diff --git a/.github/CODEOWNERS b/.github/CODEOWNERS index a5acebdb913f..36c3067db86e 100644 --- a/.github/CODEOWNERS +++ b/.github/CODEOWNERS @@ -1,72 +1 @@ -/*.md @ydb-platform/docs - -/build @ydb-platform/ci -/certs @ydb-platform/ci -/contrib @ydb-platform/ci -/devtools @ydb-platform/ci -/library @ydb-platform/ci -/scripts @ydb-platform/ci -/tools @ydb-platform/ci -/util @ydb-platform/ci -/vendor @ydb-platform/ci -/yql @ydb-platform/ci -/yt @ydb-platform/ci - -/ydb/core/fq/ @ydb-platform/fq -/ydb/core/kqp/ @ydb-platform/qp -/ydb/core/kqp/ut/federated_query @ydb-platform/fq -/ydb/core/kqp/ut/olap/ @ydb-platform/cs -/ydb/core/public_http/ @ydb-platform/fq - -/ydb/docs/ @ydb-platform/docs - -/ydb/library/yql/ @ydb-platform/yql -/ydb/library/yql/dq @ydb-platform/yql @ydb-platform/qp -/ydb/library/yql/dq/actors/common @ydb-platform/fq -/ydb/library/yql/providers/common/http_gateway @ydb-platform/fq -/ydb/library/yql/providers/common/db_id_async_resolver @ydb-platform/fq -/ydb/library/yql/providers/common/pushdown @ydb-platform/fq -/ydb/library/yql/providers/generic @ydb-platform/fq -/ydb/library/yql/providers/pq @ydb-platform/fq -/ydb/library/yql/providers/s3 @ydb-platform/fq -/ydb/library/yql/providers/solomon @ydb-platform/fq -/ydb/library/yql/tests/sql/solomon @ydb-platform/fq -/ydb/library/yql/tests/sql/suites/solomon @ydb-platform/fq -/ydb/library/yql/udfs/common/clickhouse/client @ydb-platform/fq - -/ydb/library/yql/yt @Krock21 @Krisha11 @zlobober @gritukan - -/ydb/services/fq/ @ydb-platform/fq - -/ydb/core/kafka_proxy @ydb-platform/Topics -/ydb/core/persqueue @ydb-platform/Topics -/ydb/services/datastreams @ydb-platform/Topics -/ydb/services/deprecated/persqueue_v0 @ydb-platform/Topics -/ydb/services/persqueue_v1 @ydb-platform/Topics - -/ydb/core/change_exchange @ydb-platform/core -/ydb/core/config @ydb-platform/core -/ydb/core/protos/counters_replication.proto @ydb-platform/core -/ydb/core/protos/replication.proto @ydb-platform/core -/ydb/core/tx/replication @ydb-platform/core - -/ydb/core/viewer @ydb-platform/ui-backend -/ydb/core/protos/node_whiteboard.proto @ydb-platform/ui-backend - -/ydb/core/protos/flat_scheme_op.proto @ydb-platform/schemeshard -/ydb/core/protos/flat_tx_scheme.proto @ydb-platform/schemeshard -/ydb/core/protos/counters_schemeshard.proto @ydb-platform/schemeshard -/ydb/core/protos/schemeshard @ydb-platform/schemeshard -/ydb/core/tx/scheme_board @ydb-platform/schemeshard -/ydb/core/tx/schemeshard @ydb-platform/schemeshard -/ydb/tests/functional/limits @ydb-platform/schemeshard -/ydb/tests/functional/scheme_shard @ydb-platform/schemeshard -/ydb/tests/functional/tenants/test_dynamic_tenants.py @ydb-platform/schemeshard -/ydb/core/tx/tx_proxy/schemereq.cpp @ydb-platform/schemeshard - -/ydb/core/formats/arrow @ydb-platform/cs -/ydb/core/tx/columnshard @ydb-platform/cs - -/ydb/apps/ydb @ydb-platform/cli -/ydb/public/lib/ydb_cli @ydb-platform/cli -/ydb/public/sdk/cpp @ydb-platform/cpp-sdk +* @mvgorbunov @dcherednik @va-kuznecov @alexv-smirnov @UgnineSirdis diff --git a/.github/actions/build_and_test_ya/action.yml b/.github/actions/build_and_test_ya/action.yml index 9dd86a4820ea..e142a282b8bd 100644 --- a/.github/actions/build_and_test_ya/action.yml +++ b/.github/actions/build_and_test_ya/action.yml @@ -51,12 +51,37 @@ inputs: vars: type: string default: "" + custom_branch_name: + description: "Custom branch name required when workflow branch != checkout branch" + type: string + required: false defaults: run: shell: bash runs: using: "composite" steps: + - name: Prepare folder prefix + id: prepare_prefix + shell: bash + run: | + # Check if custom_branch_name is set and not empty + if [ -n "${{ inputs.custom_branch_name }}" ]; then + # Extract and sanitize custom_branch_name + CUSTOM_BRANCH_NAME="${{ inputs.custom_branch_name }}" + # Replace all unsupported characters with hyphens + SANITIZED_NAME="${CUSTOM_BRANCH_NAME//[^a-zA-Z0-9-]/-}" + # Optionally limit the length to, say, 50 characters + SANITIZED_NAME="${SANITIZED_NAME:0:50}" + # Assign the sanitized name to the folder_prefix + FOLDER_PREFIX="ya-${SANITIZED_NAME}-" + else + # If the branch name is not provided, use a default prefix + FOLDER_PREFIX='ya-' + fi + # Output the folder_prefix for use in subsequent steps + echo "folder_prefix=${FOLDER_PREFIX}" >> $GITHUB_ENV + - name: Prepare s3cmd uses: ./.github/actions/s3cmd with: @@ -64,7 +89,7 @@ runs: s3_endpoint: ${{ fromJSON( inputs.vars ).AWS_ENDPOINT }} s3_key_id: ${{ fromJSON( inputs.secs ).AWS_KEY_ID }} s3_key_secret: ${{ fromJSON( inputs.secs ).AWS_KEY_VALUE }} - folder_prefix: ya- + folder_prefix: ${{ env.folder_prefix }} build_preset: ${{ inputs.build_preset }} - name: Run build and tests @@ -88,3 +113,4 @@ runs: bazel_remote_password: ${{ fromJSON( inputs.secs ).REMOTE_CACHE_PASSWORD || '' }} put_build_results_to_cache: ${{ inputs.put_build_results_to_cache }} test_retry_count: ${{ inputs.test_retry_count }} + custom_branch_name: ${{ inputs.custom_branch_name }} diff --git a/.github/actions/test_ya/action.yml b/.github/actions/test_ya/action.yml index 97b574459858..c41fdbbc01be 100644 --- a/.github/actions/test_ya/action.yml +++ b/.github/actions/test_ya/action.yml @@ -60,6 +60,11 @@ inputs: type: string default: "" description: "how many times to retry failed tests" + custom_branch_name: + description: "Custom branch name required when workflow branch != checkout branch" + type: string + required: false + outputs: success: value: ${{ steps.build.outputs.status }} @@ -271,8 +276,18 @@ runs: --cache-size 2TB --force-build-depends ) + echo "inputs.custom_branch_name = ${{ inputs.custom_branch_name }}" + echo "GITHUB_REF_NAME = $GITHUB_REF_NAME" + + if [ -z "${{ inputs.custom_branch_name }}" ]; then + BRANCH_NAME="${GITHUB_REF_NAME}" + else + BRANCH_NAME="${{ inputs.custom_branch_name }}" + fi + echo "BRANCH_NAME=$BRANCH_NAME" >> $GITHUB_ENV + echo "BRANCH_NAME is set to $BRANCH_NAME" - TESTMO_BRANCH_TAG="$GITHUB_REF_NAME" + TESTMO_BRANCH_TAG="$BRANCH_NAME" TESTMO_ARCH="${{ runner.arch == 'X64' && 'x86-64' || runner.arch == 'ARM64' && 'arm64' || 'unknown' }}" TESTMO_PR_NUMBER=${{ github.event.number }} @@ -453,6 +468,7 @@ runs: --public_dir "$PUBLIC_DIR" \ --public_dir_url "$PUBLIC_DIR_URL" \ --build_preset "$BUILD_PRESET" \ + --branch "$BRANCH_NAME" \ --status_report_file statusrep.txt \ --is_retry $IS_RETRY \ --is_last_retry $IS_LAST_RETRY \ @@ -470,7 +486,7 @@ runs: # upload tests results to YDB ydb_upload_run_name="${TESTMO_RUN_NAME// /"_"}" - result=`.github/scripts/analytics/upload_tests_results.py --test-results-file ${CURRENT_JUNIT_XML_PATH} --run-timestamp $(date +%s) --commit $(git rev-parse HEAD) --build-type ${BUILD_PRESET} --pull $ydb_upload_run_name --job-name "${{ github.workflow }}" --job-id "${{ github.run_id }}" --branch ${GITHUB_REF_NAME}` + result=`.github/scripts/analytics/upload_tests_results.py --test-results-file ${CURRENT_JUNIT_XML_PATH} --run-timestamp $(date +%s) --commit $(git rev-parse HEAD) --build-type ${BUILD_PRESET} --pull $ydb_upload_run_name --job-name "${{ github.workflow }}" --job-id "${{ github.run_id }}" --branch "${BRANCH_NAME}"` if [ ${{ inputs.testman_token }} ]; then # finish testme session @@ -573,7 +589,7 @@ runs: echo file ${file_to_check} NOT changed else echo file ${file_to_check} changed - .github/scripts/tests/get_muted_tests.py --output_folder "$PUBLIC_DIR/mute_info/" get_mute_diff --base_sha $ORIGINAL_HEAD~1 --head_sha $ORIGINAL_HEAD --job-id "${{ github.run_id }}" --branch "${GITHUB_REF_NAME}" + .github/scripts/tests/get_muted_tests.py --output_folder "$PUBLIC_DIR/mute_info/" get_mute_diff --base_sha $ORIGINAL_HEAD~1 --head_sha $ORIGINAL_HEAD --job-id "${{ github.run_id }}" --branch "${BRANCH_NAME}" FILE_PATH=$PUBLIC_DIR/mute_info/2_new_muted_tests.txt SEPARATOR="" if [ -f "$FILE_PATH" ]; then @@ -633,7 +649,7 @@ runs: run: | set -x export build_preset="${{ inputs.build_preset }}" - export branch_to_compare="$GITHUB_REF_NAME" + export branch_to_compare="$BRANCH_NAME" export yellow_treshold=102400 export red_treshold=2097152 export commit_git_sha="$(git rev-parse HEAD)" diff --git a/.github/actions/update_changelog/action.yaml b/.github/actions/update_changelog/action.yaml index 6ce6a023758f..aa4761d06f3c 100644 --- a/.github/actions/update_changelog/action.yaml +++ b/.github/actions/update_changelog/action.yaml @@ -40,5 +40,5 @@ runs: run: | git config --local user.email "action@github.com" git config --local user.name "GitHub Action" - git config --local github.token ${{ env.UPDATE_REPO_TOKEN }} + git config --local github.token ${{ env.GH_TOKEN }} python ${{ github.action_path }}/update_changelog.py pr_data.txt "${{ inputs.changelog_path }}" "${{ inputs.base_branch }}" "${{ inputs.suffix }}" diff --git a/.github/actions/update_changelog/update_changelog.py b/.github/actions/update_changelog/update_changelog.py index 9d0e284cd69e..bdfeb69ad5c0 100644 --- a/.github/actions/update_changelog/update_changelog.py +++ b/.github/actions/update_changelog/update_changelog.py @@ -15,6 +15,8 @@ CATEGORY_PREFIX = "### " ITEM_PREFIX = "* " +GH_TOKEN = os.getenv("GH_TOKEN") + @functools.cache def get_github_api_url(): return os.getenv('GITHUB_REPOSITORY') @@ -121,7 +123,8 @@ def update_changelog(changelog_path, pr_data): if validate_pr_description(pr["body"], is_not_for_cl_valid=False): category = extract_changelog_category(pr["body"]) category = match_pr_to_changelog_category(category) - body = extract_changelog_body(pr["body"]) + dirty_body = extract_changelog_body(pr["body"]) + body = dirty_body.replace("\r", "") if category and body: body += f" [#{pr['number']}]({pr['url']})" body += f" ([{pr['name']}]({pr['user_url']}))" @@ -150,7 +153,7 @@ def fetch_pr_details(pr_id): url = f"https://api.github.com/repos/{get_github_api_url()}/pulls/{pr_id}" headers = { "Accept": "application/vnd.github.v3+json", - "Authorization": f"token {GITHUB_TOKEN}" + "Authorization": f"token {GH_TOKEN}" } response = requests.get(url, headers=headers) response.raise_for_status() @@ -160,7 +163,7 @@ def fetch_user_details(username): url = f"https://api.github.com/users/{username}" headers = { "Accept": "application/vnd.github.v3+json", - "Authorization": f"token {GITHUB_TOKEN}" + "Authorization": f"token {GH_TOKEN}" } response = requests.get(url, headers=headers) response.raise_for_status() @@ -175,8 +178,6 @@ def fetch_user_details(username): changelog_path = sys.argv[2] base_branch = sys.argv[3] suffix = sys.argv[4] - - GITHUB_TOKEN = os.getenv("UPDATE_REPO_TOKEN") try: with open(pr_data_file, 'r') as file: @@ -190,12 +191,13 @@ def fetch_user_details(username): try: pr_details = fetch_pr_details(pr["id"]) user_details = fetch_user_details(pr_details["user"]["login"]) + name = user_details.get("name", None) if validate_pr_description(pr_details["body"], is_not_for_cl_valid=False): pr_data.append({ "number": pr_details["number"], "body": pr_details["body"].strip(), "url": pr_details["html_url"], - "name": user_details.get("name", pr_details["user"]["login"]), # Use login if name is not available + "name": name or pr_details["user"]["login"], # Use login if name is not available "user_url": pr_details["user"]["html_url"] }) except Exception as e: @@ -204,7 +206,7 @@ def fetch_user_details(username): update_changelog(changelog_path, pr_data) - base_branch_name = f"changelog-for-{base_branch}-{suffix}" + base_branch_name = f"changelog/{base_branch}-{suffix}" branch_name = base_branch_name index = 1 while branch_exists(branch_name): diff --git a/.github/config/muted_ya.txt b/.github/config/muted_ya.txt index 77b0ecc46197..c37454cacf92 100644 --- a/.github/config/muted_ya.txt +++ b/.github/config/muted_ya.txt @@ -39,21 +39,22 @@ ydb/core/kqp/ut/olap KqpOlapBlobsSharing.MultipleSplitsWithRestartsWhenWait ydb/core/kqp/ut/olap KqpOlapBlobsSharing.TableReshardingConsistency64 ydb/core/kqp/ut/olap KqpOlapBlobsSharing.TableReshardingModuloN ydb/core/kqp/ut/olap KqpOlapBlobsSharing.UpsertWhileSplitTest +ydb/core/kqp/ut/olap KqpOlapSysView.StatsSysViewBytesColumnActualization ydb/core/kqp/ut/olap KqpOlapSysView.StatsSysViewBytesDictActualization ydb/core/kqp/ut/olap KqpOlapSysView.StatsSysViewBytesDictStatActualization ydb/core/kqp/ut/olap KqpOlapWrite.TierDraftsGCWithRestart ydb/core/kqp/ut/olap [*/*] chunk chunk ydb/core/kqp/ut/query KqpAnalyze.AnalyzeTable+ColumnStore ydb/core/kqp/ut/query KqpAnalyze.AnalyzeTable-ColumnStore +ydb/core/kqp/ut/query KqpLimits.StreamWrite+Allowed +ydb/core/kqp/ut/query KqpStats.DeferredEffects+UseSink ydb/core/kqp/ut/query KqpStats.SysViewClientLost ydb/core/kqp/ut/scheme KqpOlapScheme.TenThousandColumns ydb/core/kqp/ut/scheme KqpScheme.AlterAsyncReplication ydb/core/kqp/ut/scheme [*/*] chunk chunk ydb/core/kqp/ut/scheme [*/*]+chunk+chunk -ydb/core/kqp/ut/service KqpQueryService.ExecuteQueryWithResourcePoolClassifier ydb/core/kqp/ut/service [*/*] chunk chunk ydb/core/kqp/ut/service [*/*]+chunk+chunk -ydb/core/kqp/ut/spilling KqpScanSpilling.SelfJoinQueryService ydb/core/kqp/ut/tx KqpSinkTx.OlapInvalidateOnError ydb/core/kqp/ut/tx KqpSnapshotIsolation.TConflictReadWriteOlap ydb/core/kqp/ut/tx KqpSnapshotIsolation.TConflictReadWriteOltp @@ -65,35 +66,28 @@ ydb/core/kqp/ut/tx KqpSnapshotIsolation.TReadOnlyOltp ydb/core/kqp/ut/tx KqpSnapshotIsolation.TReadOnlyOltpNoSink ydb/core/kqp/ut/tx KqpSnapshotIsolation.TSimpleOltp ydb/core/kqp/ut/tx KqpSnapshotIsolation.TSimpleOltpNoSink -ydb/core/kqp/ut/yql KqpScripting.StreamExecuteYqlScriptScanOperationTmeoutBruteForce -ydb/core/mind/hive/ut THiveTest.TestReassignUseRelativeSpace ydb/core/persqueue/ut [*/*] chunk chunk ydb/core/quoter/ut QuoterWithKesusTest.PrefetchCoefficient ydb/core/statistics/aggregator/ut AnalyzeColumnshard.AnalyzeRebootColumnShard +ydb/core/tablet_flat/ut TSharedPageCache.ClockPro ydb/core/tablet_flat/ut TSharedPageCache.Compaction_BTreeIndex ydb/core/tablet_flat/ut TSharedPageCache.ThreeLeveledLRU ydb/core/tx/datashard/ut_incremental_backup IncrementalBackup.ComplexRestoreBackupCollection+WithIncremental ydb/core/tx/schemeshard/ut_login_large TSchemeShardLoginLargeTest.RemoveLogin_Many -ydb/core/tx/schemeshard/ut_move_reboots TSchemeShardMoveRebootsTest.WithData -ydb/core/tx/schemeshard/ut_move_reboots TSchemeShardMoveRebootsTest.WithDataAndPersistentPartitionStats ydb/core/tx/schemeshard/ut_pq_reboots TPqGroupTestReboots.AlterWithReboots-PQConfigTransactionsAtSchemeShard-false -ydb/core/tx/schemeshard/ut_pq_reboots TPqGroupTestReboots.CreateAlter-PQConfigTransactionsAtSchemeShard-true -ydb/core/tx/schemeshard/ut_pq_reboots TPqGroupTestReboots.CreateAlterDropPqGroupWithReboots-PQConfigTransactionsAtSchemeShard-true +ydb/core/tx/schemeshard/ut_pq_reboots TPqGroupTestReboots.AlterWithReboots-PQConfigTransactionsAtSchemeShard-true ydb/core/tx/tiering/ut ColumnShardTiers.TTLUsage ydb/core/viewer/tests test.py.test_viewer_nodes ydb/core/viewer/tests test.py.test_viewer_sysinfo -ydb/core/viewer/ut Viewer.TabletMerging ydb/library/actors/http/ut sole chunk chunk ydb/library/actors/http/ut sole+chunk+chunk ydb/library/actors/interconnect/ut_huge_cluster HugeCluster.AllToAll ydb/library/actors/interconnect/ut_huge_cluster sole chunk chunk -ydb/library/yql/providers/generic/connector/tests/datasource/ydb test.py.test_select_positive[column_selection_col2_COL1-kqprun] ydb/library/yql/providers/generic/connector/tests/join test.py.test_join[join_ch_ch-kqprun] ydb/library/yql/providers/generic/connector/tests/join test.py.test_join[join_pg_pg-kqprun] +ydb/public/sdk/cpp/src/client/topic/ut TxUsage.Sinks_Oltp_WriteToTopicAndTable_6_Query ydb/services/keyvalue/ut sole chunk chunk ydb/services/keyvalue/ut sole+chunk+chunk -ydb/services/persqueue_v1/ut TPersQueueCommonTest.TestLimiterLimitsWithBlobsRateLimit -ydb/services/persqueue_v1/ut TPersQueueCommonTest.TestLimiterLimitsWithUserPayloadRateLimit ydb/services/ydb/sdk_sessions_pool_ut YdbSdkSessionsPool.StressTestSync1 ydb/services/ydb/sdk_sessions_pool_ut YdbSdkSessionsPool.StressTestSync10 ydb/services/ydb/sdk_sessions_ut YdbSdkSessions.TestSdkFreeSessionAfterBadSessionQueryService @@ -104,16 +98,9 @@ ydb/services/ydb/ut YdbLogStore.AlterLogTable ydb/tests/fq/control_plane_storage [*/*] chunk chunk ydb/tests/fq/control_plane_storage [*/*]+chunk+chunk ydb/tests/fq/generic/analytics sole chunk chunk -ydb/tests/fq/generic/analytics test_join.py.TestJoinAnalytics.test_simple[v1-2-fq_client0-mvp_external_ydb_endpoint0] +ydb/tests/fq/generic/analytics test_join.py.TestJoinAnalytics.test_simple[v1-fq_client0-mvp_external_ydb_endpoint0] +ydb/tests/fq/generic/analytics test_join.py.TestJoinAnalytics.test_simple[v2-fq_client0-mvp_external_ydb_endpoint0] ydb/tests/fq/generic/streaming sole chunk chunk -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_simple[v1-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-0-True-3-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-1-True-3-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-2-True-3-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-3-True-3-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-4-True-3-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-5-True-3-fq_client0-mvp_external_ydb_endpoint0] -ydb/tests/fq/generic/streaming test_join.py.TestJoinStreaming.test_streamlookup[v1-6-True-3-fq_client0-mvp_external_ydb_endpoint0] ydb/tests/fq/mem_alloc sole chunk chunk ydb/tests/fq/mem_alloc sole+chunk+chunk ydb/tests/fq/mem_alloc test_scheduling.py.TestSchedule.test_skip_busy[kikimr0] @@ -128,28 +115,30 @@ ydb/tests/fq/yds [*/*] chunk chunk ydb/tests/fq/yds [*/*]+chunk+chunk ydb/tests/fq/yds test_2_selects_limit.py.TestSelectLimit.test_select_same[v1] ydb/tests/fq/yds test_2_selects_limit.py.TestSelectLimit.test_select_sequence[v1] -ydb/tests/fq/yds test_big_state.py.TestBigState.test_gt_8mb[v1] ydb/tests/fq/yds test_mem_alloc.py.TestMemAlloc.test_hop_alloc[v1] ydb/tests/fq/yds test_mem_alloc.py.TestMemAlloc.test_join_alloc[v1] ydb/tests/fq/yds test_recovery.py.TestRecovery.test_ic_disconnection ydb/tests/fq/yds test_select_limit_db_id.py.TestSelectLimitWithDbId.test_select_same_with_id[v1-mvp_external_ydb_endpoint0] ydb/tests/fq/yds test_yds_bindings.py.TestBindings.test_yds_insert[v1] -ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_simple -ydb/tests/functional/compatibility test_followers.py.TestFollowersCompatibility.test_followers_compatability +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_export[current_to_current] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_export[current_to_stable_24_4] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_export[stable_24_4_to_current] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_export[stable_24_4_to_current_mixed] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_tpch1[current_to_current-column] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_tpch1[current_to_current-row] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_tpch1[current_to_stable_24_4-column] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_tpch1[stable_24_4_to_current-column] +ydb/tests/functional/compatibility test_compatibility.py.TestCompatibility.test_tpch1[stable_24_4_to_current_mixed-column] +ydb/tests/functional/compatibility test_stress.py.TestStress.test_log[current-row] +ydb/tests/functional/compatibility test_stress.py.TestStress.test_log[mixed-row] ydb/tests/functional/hive test_drain.py.TestHive.test_drain_on_stop ydb/tests/functional/rename [test_rename.py */*] chunk chunk -ydb/tests/functional/restarts test_restarts.py.TestRestartSingleBlock42.test_restart_single_node_is_ok ydb/tests/functional/serializable sole chunk chunk -ydb/tests/functional/serializable test.py.test_local ydb/tests/functional/serverless test_serverless.py.test_database_with_disk_quotas[enable_alter_database_create_hive_first--false] ydb/tests/functional/serverless test_serverless.py.test_database_with_disk_quotas[enable_alter_database_create_hive_first--true] ydb/tests/functional/suite_tests test_postgres.py.TestPGSQL.test_sql_suite[plan-jointest/join2.test] -ydb/tests/functional/tenants test_dynamic_tenants.py.test_create_and_drop_the_same_tenant2[enable_alter_database_create_hive_first--false] -ydb/tests/functional/tenants test_dynamic_tenants.py.test_create_and_drop_the_same_tenant2[enable_alter_database_create_hive_first--true] ydb/tests/functional/tenants test_tenants.py.TestTenants.test_create_drop_create_table3[enable_alter_database_create_hive_first--false] ydb/tests/functional/tenants test_tenants.py.TestTenants.test_create_drop_create_table3[enable_alter_database_create_hive_first--true] -ydb/tests/functional/tenants test_tenants.py.TestTenants.test_list_database_above[enable_alter_database_create_hive_first--false] -ydb/tests/functional/tenants test_tenants.py.TestTenants.test_list_database_above[enable_alter_database_create_hive_first--true] ydb/tests/functional/tenants test_tenants.py.TestTenants.test_stop_start[enable_alter_database_create_hive_first--false] ydb/tests/functional/tenants test_tenants.py.TestTenants.test_stop_start[enable_alter_database_create_hive_first--true] ydb/tests/functional/tpc/large [test_tpcds.py] chunk chunk @@ -171,82 +160,17 @@ ydb/tests/olap/ttl_tiering sole chunk chunk ydb/tests/olap/ttl_tiering ttl_delete_s3.py.TestDeleteS3Ttl.test_data_unchanged_after_ttl_change ydb/tests/olap/ttl_tiering ttl_delete_s3.py.TestDeleteS3Ttl.test_ttl_delete ydb/tests/olap/ttl_tiering ttl_unavailable_s3.py.TestUnavailableS3.test -ydb/tests/olap/ttl_tiering unstable_connection.py.TestUnstableConnection.test ydb/tests/postgres_integrations/go-libpq [docker_wrapper_test.py] chunk chunk -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[Test64BitErrorChecking] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestArrayValueBackend] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestBinaryByteSliceToInt] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestBinaryByteSlicetoUUID] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestBindError] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCommit] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestConnListen] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestConnPing] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestConnUnlistenAll] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestConnUnlisten] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestConnectorWithNoticeHandler_Simple] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestConnectorWithNotificationHandler_Simple] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestContextCancelBegin] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestContextCancelExec] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestContextCancelQuery] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyFromError] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyInBinaryError] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyInMultipleValues] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyInRaiseStmtTrigger] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyInStmtAffectedRows] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyInTypes] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyInWrongType] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopyRespLoopConnectionError] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestCopySyntaxError] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestEmptyQuery] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestEncodeDecode] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestErrorClass] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestErrorDuringStartup] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestErrorOnExec] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestErrorOnQueryRowSimpleQuery] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestErrorOnQuery] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestExec] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestFormatTsBackend] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestHasCorrectRootGroupPermissions] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestInfinityTimestamp] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestIssue1046] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestIssue1062] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestIssue186] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestListenerFailedQuery] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestListenerListen] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestListenerPing] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestListenerReconnect] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestListenerUnlistenAll] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestListenerUnlisten] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestNewConnector_Connect] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestNewConnector_Driver] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestNewConnector_WorksWithOpenDB] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestNotifyExtra] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestNullAfterNonNull] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestParseErrorInExtendedQuery] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestPing] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestQueryCancelRace] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestQueryCancelledReused] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestQueryRowBugWorkaround] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestReconnect] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestReturning] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestRowsResultTag] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestRuntimeParameters] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtExecContext/context.Background] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtExecContext/context.WithTimeout] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtExecContext/context.WithTimeout_exceeded] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtExecContext] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtQueryContext/context.Background] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtQueryContext/context.WithTimeout] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtQueryContext/context.WithTimeout_exceeded] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStmtQueryContext] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestStringWithNul] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestTimestampWithTimeZone] -ydb/tests/postgres_integrations/go-libpq docker_wrapper_test.py.test_pg_generated[TestTxOptions] ydb/tests/sql sole chunk chunk ydb/tests/sql/large sole chunk chunk +ydb/tests/sql/large test_bulkupserts_tpch.py.TestTpchBulkUpsertsOperations.test_bulk_upsert_lineitem_with_overlapping_keys +ydb/tests/sql/large test_bulkupserts_tpch.py.TestTpchBulkUpsertsOperations.test_repeated_bulk_upsert_lineitem ydb/tests/sql/large test_insert_delete_duplicate_records.py.TestConcurrentInsertDeleteAndRead.test_bulkupsert_delete_and_read_tpch ydb/tests/sql/large test_insert_delete_duplicate_records.py.TestConcurrentInsertDeleteAndRead.test_insert_delete_and_read_simple_tx +ydb/tests/sql/large test_insert_delete_duplicate_records.py.TestConcurrentInsertDeleteAndRead.test_insert_delete_and_read_simpletable +ydb/tests/sql/large test_insert_delete_duplicate_records.py.TestConcurrentInsertDeleteAndRead.test_upsert_delete_and_read_tpch ydb/tests/sql/large test_insert_delete_duplicate_records.py.TestConcurrentInsertDeleteAndRead.test_upsert_delete_and_read_tpch_tx +ydb/tests/sql/large test_insertinto_selectfrom.py.TestConcurrentInsertAndCount.test_concurrent_bulkinsert_and_count ydb/tests/sql/large test_insertinto_selectfrom.py.TestConcurrentInsertAndCount.test_concurrent_upsert_and_count ydb/tests/sql/large test_insertinto_selectfrom.py.TestConcurrentInsertAndCount.test_concurrent_upsert_and_count_tx ydb/tests/sql/large test_tiering.py.TestYdbS3TTL.test_basic_tiering_operations diff --git a/.github/docker/Dockerfile b/.github/docker/Dockerfile index d266c29a933a..e3dc58d4003a 100644 --- a/.github/docker/Dockerfile +++ b/.github/docker/Dockerfile @@ -44,6 +44,7 @@ COPY --from=builder \ EXPOSE ${GRPC_TLS_PORT:-2135} EXPOSE ${GRPC_PORT:-2136} EXPOSE ${MON_PORT:-8765} +EXPOSE ${YDB_KAFKA_PROXY_PORT:-9092} HEALTHCHECK --start-period=60s --interval=1s CMD sh ./health_check diff --git a/.github/docker/files/initialize_local_ydb b/.github/docker/files/initialize_local_ydb index eac175da2ff4..5d3b5943c329 100644 --- a/.github/docker/files/initialize_local_ydb +++ b/.github/docker/files/initialize_local_ydb @@ -7,6 +7,7 @@ export YDB_GRPC_ENABLE_TLS="true" export GRPC_TLS_PORT=${GRPC_TLS_PORT:-2135} export GRPC_PORT=${GRPC_PORT:-2136} export YDB_GRPC_TLS_DATA_PATH="/ydb_certs" +export YDB_KAFKA_PROXY_PORT=${YDB_KAFKA_PROXY_PORT:-9092} # Start local_ydb tool. Pass additional arguments for local_ydb /local_ydb deploy --ydb-working-dir /ydb_data --ydb-binary-path /ydbd --fixed-ports --dont-use-log-files "$@"; diff --git a/.github/scripts/analytics/data_mart_delete_table.py b/.github/scripts/analytics/data_mart_delete_table.py new file mode 100644 index 000000000000..76121b3fc523 --- /dev/null +++ b/.github/scripts/analytics/data_mart_delete_table.py @@ -0,0 +1,86 @@ +#!/usr/bin/env python3 + +import argparse +import ydb +import configparser +import os + +# Load configuration +dir = os.path.dirname(__file__) +config = configparser.ConfigParser() +config_file_path = f"{dir}/../../config/ydb_qa_db.ini" +config.read(config_file_path) + +DATABASE_ENDPOINT = config["QA_DB"]["DATABASE_ENDPOINT"] +DATABASE_PATH = config["QA_DB"]["DATABASE_PATH"] + +def parse_args(): + parser = argparse.ArgumentParser(description="Delete a YDB table") + parser.add_argument("--table_path", required=True, help="Table path and name to delete") + + return parser.parse_args() + +def check_table_exists(session, table_path): + """Check if table exists""" + try: + session.describe_table(table_path) + return True + except ydb.SchemeError: + return False + +def delete_table(session, table_path): + """Delete the specified table.""" + try: + session.drop_table(table_path) + print(f"Table '{table_path}' successfully deleted.") + return True + except ydb.Error as e: + print(f"Error deleting table: {e}") + return False + +def main(): + args = parse_args() + + if "CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS" not in os.environ: + print("Error: Env variable CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS is missing, skipping") + return 1 + else: + os.environ["YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS"] = os.environ[ + "CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS" + ] + + table_path = args.table_path + full_table_path = f'{DATABASE_PATH}/{table_path}' + + print(f"Connecting to YDB to delete table {full_table_path}") + + with ydb.Driver( + endpoint=DATABASE_ENDPOINT, + database=DATABASE_PATH, + credentials=ydb.credentials_from_env_variables() + ) as driver: + # Wait until driver is ready + driver.wait(timeout=10, fail_fast=True) + + with ydb.SessionPool(driver) as pool: + # Проверяем существование таблицы + def check_and_delete(session): + exists = check_table_exists(session, full_table_path) + if exists: + return delete_table(session, full_table_path) + else: + print(f"Table '{full_table_path}' does not exist.") + return False + + result = pool.retry_operation_sync(check_and_delete) + + if result: + print(f"Table {full_table_path} has been deleted successfully.") + return 0 + else: + print(f"No table was deleted.") + return 1 + +if __name__ == "__main__": + exit_code = main() + exit(exit_code) diff --git a/.github/scripts/analytics/data_mart_queries/muted_test_mart.sql b/.github/scripts/analytics/data_mart_queries/muted_test_mart.sql new file mode 100644 index 000000000000..3e7c3d31619c --- /dev/null +++ b/.github/scripts/analytics/data_mart_queries/muted_test_mart.sql @@ -0,0 +1,35 @@ +SELECT + build_type , + job_name, + job_id, + commit, + branch, + pull, + run_timestamp, + test_id, + suite_folder, + test_name, + cast(suite_folder || '/' || test_name as UTF8) as full_name, + duration, + status, + String::ReplaceAll(status_description, ';;', '\n') as status_description, + owners, + String::ReplaceAll(owners, 'TEAM:@ydb-platform/', '') as owner_team, + String::SplitToList(pull,'_A')[0] as pull_raw, + cast(COALESCE(String::SplitToList(pull,'_A')[1],"1") as Uint16) as attempt, + (cast(pull as String) || '_' || SUBSTRING(cast(commit as String), 1, 8)) as pull_commit, + CASE + WHEN String::Contains(test_name, 'chunk chunk') OR String::Contains(test_name, 'chunk+chunk') THEN TRUE + ELSE FALSE + END as with_cunks + +FROM `test_results/test_runs_column` + +WHERE + run_timestamp >= CurrentUtcDate() - 6*Interval("P1D") + and build_type = 'relwithdebinfo' + and String::Contains(test_name, '.flake8') = FALSE + and (CASE + WHEN String::Contains(test_name, 'chunk chunk') OR String::Contains(test_name, 'chunk+chunk') THEN TRUE + ELSE FALSE + END) = FALSE diff --git a/.github/scripts/analytics/data_mart_queries/test_history_fast_mart.sql b/.github/scripts/analytics/data_mart_queries/test_history_fast_mart.sql new file mode 100644 index 000000000000..8245527f3368 --- /dev/null +++ b/.github/scripts/analytics/data_mart_queries/test_history_fast_mart.sql @@ -0,0 +1,25 @@ +SELECT + build_type, + job_name, + job_id, + commit, + branch, + pull, + run_timestamp, + test_id, + suite_folder, + test_name, + cast(suite_folder || '/' || test_name as UTF8) as full_name, + duration, + status, + cast(String::ReplaceAll(status_description, ';;', '\n')as Utf8) as status_description , + owners + FROM `test_results/test_runs_column` as all_data + WHERE + run_timestamp >= CurrentUtcDate() - Interval("P1D") + and String::Contains(test_name, '.flake8') = FALSE + and (CASE + WHEN String::Contains(test_name, 'chunk chunk') OR String::Contains(test_name, 'chunk+chunk') THEN TRUE + ELSE FALSE + END) = FALSE + and (branch = 'main' or branch like 'stable-%') diff --git a/.github/scripts/analytics/data_mart_queries/test_monitor_mart.sql b/.github/scripts/analytics/data_mart_queries/test_monitor_mart.sql new file mode 100644 index 000000000000..4383be240345 --- /dev/null +++ b/.github/scripts/analytics/data_mart_queries/test_monitor_mart.sql @@ -0,0 +1,44 @@ +SELECT + state_filtered, + test_name, + suite_folder, + full_name, + date_window, + build_type, + branch, + days_ago_window, + pass_count, + mute_count, + fail_count, + skip_count, + owner, + is_muted, + is_test_chunk, + state, + previous_state, + state_change_date, + days_in_state, + previous_mute_state, + mute_state_change_date, + days_in_mute_state, + previous_state_filtered, + state_change_date_filtered, + days_in_state_filtered, + CASE + WHEN (state = 'Skipped' AND days_in_state > 14) THEN 'Skipped' + WHEN days_in_mute_state >= 30 THEN 'MUTED: delete candidate' + ELSE 'MUTED: in sla' + END as resolution, + String::ReplaceAll(owner, 'TEAM:@ydb-platform/', '') as owner_team, + CASE + WHEN is_muted = 1 OR (state = 'Skipped' AND days_in_state > 14) THEN TRUE + ELSE FALSE + END as is_muted_or_skipped +FROM `test_results/analytics/tests_monitor` +WHERE date_window >= CurrentUtcDate() - 30 * Interval("P1D") +and ( branch = 'main' or branch like 'stable-%') +and is_test_chunk = 0 +and (CASE + WHEN is_muted = 1 OR (state = 'Skipped' AND days_in_state > 14) THEN TRUE + ELSE FALSE + END ) = TRUE diff --git a/.github/scripts/analytics/data_mart_ttl_analog.py b/.github/scripts/analytics/data_mart_ttl_analog.py new file mode 100644 index 000000000000..9d80406ca0c2 --- /dev/null +++ b/.github/scripts/analytics/data_mart_ttl_analog.py @@ -0,0 +1,102 @@ +#!/usr/bin/env python3 + +import argparse +import ydb +import configparser +import os +import time + +# Load configuration +dir = os.path.dirname(__file__) +config = configparser.ConfigParser() +config_file_path = f"{dir}/../../config/ydb_qa_db.ini" +config.read(config_file_path) + +DATABASE_ENDPOINT = config["QA_DB"]["DATABASE_ENDPOINT"] +DATABASE_PATH = config["QA_DB"]["DATABASE_PATH"] + +def parse_args(): + parser = argparse.ArgumentParser(description="Delete old records from YDB table") + parser.add_argument("--table-path", required=True, help="Table path and name") + parser.add_argument("--timestamp-field", required=True, help="Name of the timestamp field") + parser.add_argument("--delete-interval", required=True, help="Interval to delete records older than, in ISO 8601 format (https://en.wikipedia.org/wiki/ISO_8601#Durations) without 'P'") + + return parser.parse_args() + +def delete_old_records(session, full_table_path, timestamp_field, delete_interval): + """Delete records older than the specified interval.""" + # First, count the number of records that will be deleted + count_query = f""" + SELECT COUNT(*) as count + FROM `{full_table_path}` + WHERE `{timestamp_field}` < CurrentUtcDate() - Interval("P{delete_interval}") + """ + + print(f"Counting records to delete...") + result_sets = session.transaction().execute(count_query) + row_count = result_sets[0].rows[0].count + + if row_count == 0: + print("No records to delete.") + return 0 + + print(f"Found {row_count} records older than {delete_interval}.") + + # Now perform the delete operation + delete_query = f""" + DELETE FROM `{full_table_path}` + WHERE `{timestamp_field}` < CurrentUtcDate() - Interval("P{delete_interval}") + """ + + print(f"Executing DELETE query: {delete_query}") + start_time = time.time() + session.transaction().execute(delete_query, commit_tx=True) + end_time = time.time() + + print(f"Deleted {row_count} records in {end_time - start_time:.2f} seconds.") + return row_count + +def main(): + args = parse_args() + + if "CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS" not in os.environ: + print("Error: Env variable CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS is missing, skipping") + return 1 + else: + os.environ["YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS"] = os.environ[ + "CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS" + ] + + table_path = args.table_path + full_table_path = f'{DATABASE_PATH}/{table_path}' + timestamp_field = args.timestamp_field + delete_interval = args.delete_interval + + print(f"Connecting to YDB to delete records from {full_table_path}") + print(f"Will delete records where {timestamp_field} < CurrentUtcDate() - Interval(\"P{delete_interval}\")") + + with ydb.Driver( + endpoint=DATABASE_ENDPOINT, + database=DATABASE_PATH, + credentials=ydb.credentials_from_env_variables() + ) as driver: + # Wait until driver is ready + driver.wait(timeout=10, fail_fast=True) + + with ydb.SessionPool(driver) as pool: + try: + def transaction_delete(session): + return delete_old_records(session, full_table_path, timestamp_field, delete_interval) + + deleted_count = pool.retry_operation_sync(transaction_delete) + + print(f"Successfully deleted old records from {full_table_path}") + print(f"Total records deleted: {deleted_count}") + return 0 + except ydb.Error as e: + print(f"Error deleting records: {e}") + return 1 + +if __name__ == "__main__": + exit_code = main() + exit(exit_code) diff --git a/.github/scripts/analytics/flaky_tests_history.py b/.github/scripts/analytics/flaky_tests_history.py index 617d815bcc7d..8133b042de67 100755 --- a/.github/scripts/analytics/flaky_tests_history.py +++ b/.github/scripts/analytics/flaky_tests_history.py @@ -78,8 +78,8 @@ def main(): parser = argparse.ArgumentParser() parser.add_argument('--days-window', default=1, type=int, help='how many days back we collecting history') - parser.add_argument('--build_type',choices=['relwithdebinfo', 'release-asan'], default='relwithdebinfo', type=str, help='build : relwithdebinfo or release-asan') - parser.add_argument('--branch', default='main',choices=['main'], type=str, help='branch') + parser.add_argument('--build_type', default='relwithdebinfo', type=str, help='build types') + parser.add_argument('--branch', default='main', type=str, help='branch') args, unknown = parser.parse_known_args() history_for_n_day = args.days_window @@ -203,6 +203,9 @@ def main(): and job_name in ( 'Nightly-run', 'Regression-run', + 'Regression-run_Large', + 'Regression-run_Small_and_Medium', + 'Regression-run_compatibility', 'Regression-whitelist-run', 'Postcommit_relwithdebinfo', 'Postcommit_asan' diff --git a/.github/scripts/analytics/flaky_tests_history_n_runs.py b/.github/scripts/analytics/flaky_tests_history_n_runs.py index 1c4787a45c59..c35046374e25 100755 --- a/.github/scripts/analytics/flaky_tests_history_n_runs.py +++ b/.github/scripts/analytics/flaky_tests_history_n_runs.py @@ -203,6 +203,9 @@ def main(): and job_name in ( 'Nightly-run', 'Regression-run', + 'Regression-run_Large', + 'Regression-run_Small_and_Medium', + 'Regression-run_compatibility', 'Regression-whitelist-run', 'Postcommit_relwithdebinfo', 'Postcommit_asan' @@ -227,6 +230,9 @@ def main(): and job_name in ( 'Nightly-run', 'Regression-run', + 'Regression-run_Large', + 'Regression-run_Small_and_Medium', + 'Regression-run_compatibility', 'Regression-whitelist-run', 'Postcommit_relwithdebinfo', 'Postcommit_asan' diff --git a/.github/scripts/analytics/test_history_fast.py b/.github/scripts/analytics/test_history_fast.py index cf14a3836370..7dc78b484f16 100755 --- a/.github/scripts/analytics/test_history_fast.py +++ b/.github/scripts/analytics/test_history_fast.py @@ -19,6 +19,17 @@ def drop_table(session, table_path): session.execute_scheme(f"DROP TABLE IF EXISTS `{table_path}`;") +def check_table_exists(session, table_path): + """Check if table exists""" + try: + session.describe_table(table_path) + print(f"Table '{table_path}' already exists.") + return True + except ydb.SchemeError: + print(f"Table '{table_path}' does not exist.") + return False + + def create_test_history_fast_table(session, table_path): print(f"> Creating table: '{table_path}'") session.execute_scheme(f""" @@ -38,7 +49,7 @@ def create_test_history_fast_table(session, table_path): `status` Utf8, `status_description` Utf8, `owners` Utf8, - PRIMARY KEY (`full_name`, `run_timestamp`, `job_name`, `branch`, `build_type`, test_id) + PRIMARY KEY (`run_timestamp`, `full_name`, `job_name`, `branch`, `build_type`, test_id) ) PARTITION BY HASH(run_timestamp) WITH ( @@ -74,7 +85,7 @@ def bulk_upsert(table_client, table_path, rows): def get_missed_data_for_upload(driver): results = [] query = f""" - SELECT + SELECT build_type, job_name, job_id, @@ -96,8 +107,14 @@ def get_missed_data_for_upload(driver): ) as fast_data_missed ON all_data.run_timestamp = fast_data_missed.run_timestamp WHERE - all_data.run_timestamp >= CurrentUtcDate() - 6*Interval("P1D") AND - fast_data_missed.run_timestamp is NULL + all_data.run_timestamp >= CurrentUtcDate() - 6*Interval("P1D") + and String::Contains(all_data.test_name, '.flake8') = FALSE + and (CASE + WHEN String::Contains(all_data.test_name, 'chunk chunk') OR String::Contains(all_data.test_name, 'chunk+chunk') THEN TRUE + ELSE FALSE + END) = FALSE + and (all_data.branch = 'main' or all_data.branch like 'stable-%') + and fast_data_missed.run_timestamp is NULL """ scan_query = ydb.ScanQuery(query, {}) @@ -127,7 +144,8 @@ def main(): ] table_path = "test_results/analytics/test_history_fast" - batch_size = 50000 + full_table_path = f'{DATABASE_PATH}/{table_path}' + batch_size = 1000 with ydb.Driver( endpoint=DATABASE_ENDPOINT, @@ -136,13 +154,24 @@ def main(): ) as driver: driver.wait(timeout=10, fail_fast=True) with ydb.SessionPool(driver) as pool: + # Проверяем существование таблицы и создаем её если нужно + def check_and_create_table(session): + exists = check_table_exists(session, full_table_path) + if not exists: + create_test_history_fast_table(session, full_table_path) + return True + return exists + + pool.retry_operation_sync(check_and_create_table) + + # Продолжаем с основной логикой скрипта prepared_for_upload_rows = get_missed_data_for_upload(driver) print(f'Preparing to upsert: {len(prepared_for_upload_rows)} rows') if prepared_for_upload_rows: for start in range(0, len(prepared_for_upload_rows), batch_size): batch_rows_for_upload = prepared_for_upload_rows[start:start + batch_size] print(f'upserting: {start}-{start + len(batch_rows_for_upload)}/{len(prepared_for_upload_rows)} rows') - bulk_upsert(driver.table_client, f'{DATABASE_PATH}/{table_path}', batch_rows_for_upload) + bulk_upsert(driver.table_client, full_table_path, batch_rows_for_upload) print('Tests uploaded') else: print('Nothing to upload') diff --git a/.github/scripts/analytics/tests_monitor.py b/.github/scripts/analytics/tests_monitor.py index 538d398156c0..4c89f54e5442 100755 --- a/.github/scripts/analytics/tests_monitor.py +++ b/.github/scripts/analytics/tests_monitor.py @@ -283,12 +283,12 @@ def main(): parser.add_argument('--days-window', default=1, type=int, help='how many days back we collecting history') parser.add_argument( '--build_type', - choices=['relwithdebinfo', 'release-asan'], + choices=['relwithdebinfo', 'release-asan', 'release-tsan', 'release-msan'], default='relwithdebinfo', type=str, - help='build : relwithdebinfo or release-asan', + help='build type', ) - parser.add_argument('--branch', default='main', choices=['main'], type=str, help='branch') + parser.add_argument('--branch', default='main', type=str, help='branch') parser.add_argument( '--concurent', @@ -325,7 +325,7 @@ def main(): tc_settings = ydb.TableClientSettings().with_native_date_in_result_sets(enabled=False) table_client = ydb.TableClient(driver, tc_settings) base_date = datetime.datetime(1970, 1, 1) - default_start_date = datetime.date(2024, 11, 1) + default_start_date = datetime.date(2025, 2, 1) today = datetime.date.today() table_path = f'test_results/analytics/tests_monitor' diff --git a/.github/scripts/analytics/upload_testowners.py b/.github/scripts/analytics/upload_testowners.py index 05cae9b04f06..ed20ffcbf03b 100755 --- a/.github/scripts/analytics/upload_testowners.py +++ b/.github/scripts/analytics/upload_testowners.py @@ -1,11 +1,8 @@ #!/usr/bin/env python3 -import argparse import configparser -import datetime import os import posixpath -import traceback import time import ydb from collections import Counter @@ -95,6 +92,9 @@ def main(): and job_name in ( 'Nightly-run', 'Regression-run', + 'Regression-run_Large', + 'Regression-run_Small_and_Medium', + 'Regression-run_compatibility', 'Regression-whitelist-run', 'Postcommit_relwithdebinfo', 'Postcommit_asan' diff --git a/.github/scripts/create_or_update_pr.py b/.github/scripts/create_or_update_pr.py new file mode 100644 index 000000000000..0663def20c5d --- /dev/null +++ b/.github/scripts/create_or_update_pr.py @@ -0,0 +1,103 @@ +#!/usr/bin/env python3 +import os +import argparse +from github import Github + + +def read_body_from_file(file_path): + with open(file_path, 'r') as file: + return file.read() + + +def get_body_content(body_input): + """Determines if the body content is a file path or direct text.""" + if os.path.isfile(body_input): + print(f"Body content will be read from file: {body_input}.") + return read_body_from_file(body_input) + else: + print(f"Body content will be taken directly: '{body_input}.'") + return body_input + + +def create_or_update_pr(args, repo): + current_pr = None + pr_number = None + body = get_body_content(args.body) + + owner = repo.owner.login + head_format = f"{owner}:{args.branch_for_pr}" + + print(f"Searching for PR with head branch '{head_format}' and base branch '{args.base_branch}'") + + existing_prs = repo.get_pulls(head=head_format, base=args.base_branch, state='open') + + if existing_prs.totalCount > 0: + current_pr = existing_prs[0] + print(f"Found existing PR #{current_pr.number}: {current_pr.title}") + + if current_pr: + print(f"Updating existing PR #{current_pr.number}.") + current_pr.edit(title=args.title, body=body) + print(f"PR #{current_pr.number} updated successfully.") + else: + print(f"No existing PR found. Creating a new PR from '{args.branch_for_pr}' to '{args.base_branch}'.") + current_pr = repo.create_pull(title=args.title, body=body, head=args.branch_for_pr, base=args.base_branch) + print(f"New PR #{current_pr.number} created successfully.") + + pr_number = current_pr.number + github_output = os.environ.get('GITHUB_OUTPUT') + if github_output: + with open(github_output, 'a') as gh_out: + print(f"pr_number={pr_number}", file=gh_out) + + print(f"PR operation completed. PR number: {pr_number}") + return pr_number + + +def append_to_pr_body(args, repo): + body_to_append = get_body_content(args.body) + + print(f"Looking for PR by number: {args.pr_number}") + pr = repo.get_pull(args.pr_number) + + if pr: + print(f"Appending to PR #{pr.number}.") + current_body = pr.body or "" + new_body = current_body + "\n\n" + body_to_append + pr.edit(body=new_body) + print(f"PR #{pr.number} body updated successfully.") + else: + print("No matching pull request found to append body.") + + +if __name__ == '__main__': + parser = argparse.ArgumentParser(description='Operate on a GitHub Pull Request') + subparsers = parser.add_subparsers(dest='mode', required=True, help='Mode of operation') + + # Subparser for create or update PR mode + create_parser = subparsers.add_parser('create_or_update', help='Create or update a pull request') + create_parser.add_argument('--base_branch', type=str, required=True, help='Base branch for the PR') + create_parser.add_argument('--branch_for_pr', type=str, required=True, help='Branch from which to create the PR') + create_parser.add_argument('--title', type=str, required=True, help='Title of the PR') + create_parser.add_argument('--body', type=str, default='', required=False, help='Body content of the PR, or path to a file with the content') + + # Subparser for append PR body mode + append_parser = subparsers.add_parser('append_pr_body', help='Append text to the body of an existing pull request') + group = append_parser.add_mutually_exclusive_group(required=True) + group.add_argument('--pr_number', type=int, help='Pull request number') + append_parser.add_argument('--body', type=str, required=True, help='Text to append to the PR body') + + args = parser.parse_args() + + GITHUB_TOKEN = os.getenv('GITHUB_TOKEN') + if not GITHUB_TOKEN: + raise ValueError("GITHUB_TOKEN environment variable is not set") + + g = Github(GITHUB_TOKEN) + repo_name = os.getenv('GITHUB_REPOSITORY', 'ydb-platform/ydb') + repo = g.get_repo(repo_name) + + if args.mode == "create_or_update": + create_or_update_pr(args, repo) + elif args.mode == "append_pr_body": + append_to_pr_body(args, repo) diff --git a/.github/scripts/tests/create_new_muted_ya.py b/.github/scripts/tests/create_new_muted_ya.py index 0549e6537304..e2aae4931d9f 100755 --- a/.github/scripts/tests/create_new_muted_ya.py +++ b/.github/scripts/tests/create_new_muted_ya.py @@ -28,8 +28,8 @@ DATABASE_PATH = config["QA_DB"]["DATABASE_PATH"] -def execute_query(driver): - query_string = ''' +def execute_query(driver, branch='main', build_type='relwithdebinfo'): + query_string = f''' SELECT * from ( SELECT data.*, CASE WHEN new_flaky.full_name IS NOT NULL THEN True ELSE False END AS new_flaky_today, @@ -101,7 +101,7 @@ def execute_query(driver): and data.build_type = deleted.build_type and data.branch = deleted.branch ) - where date_window = CurrentUtcDate() and branch = 'main' + where date_window = CurrentUtcDate() and branch = '{branch}' and build_type = '{build_type}' ''' @@ -178,8 +178,8 @@ def apply_and_add_mutes(all_tests, output_path, mute_check): for test in all_tests if test.get('days_in_state') >= 1 and test.get('flaky_today') - and (test.get('pass_count') + test.get('fail_count')) >= 3 - and test.get('fail_count') > 2 + and (test.get('pass_count') + test.get('fail_count')) >= 2 + and test.get('fail_count') >= 2 and test.get('fail_count')/(test.get('pass_count') + test.get('fail_count')) > 0.2 # <=80% success rate ) flaky_tests = sorted(flaky_tests) @@ -191,8 +191,8 @@ def apply_and_add_mutes(all_tests, output_path, mute_check): for test in all_tests if test.get('days_in_state') >= 1 and test.get('flaky_today') - and (test.get('pass_count') + test.get('fail_count')) >= 3 - and test.get('fail_count') > 2 + and (test.get('pass_count') + test.get('fail_count')) >=2 + and test.get('fail_count') >= 2 and test.get('fail_count')/(test.get('pass_count') + test.get('fail_count')) > 0.2 # <=80% success rate ) ## тесты может запускаться 1 раз в день. если за последние 7 дней набирается трешход то мьютим @@ -348,6 +348,22 @@ def create_mute_issues(all_tests, file_path): print("\n\n") print("\n".join(results)) + if 'GITHUB_OUTPUT' in os.environ: + if 'GITHUB_WORKSPACE' not in os.environ: + raise EnvironmentError("GITHUB_WORKSPACE environment variable is not set.") + + file_path = os.path.join(os.environ['GITHUB_WORKSPACE'], "created_issues.txt") + print(f"Writing results to {file_path}") + + with open(file_path, 'w') as f: + f.write("\n") + f.write("\n".join(results)) + f.write("\n") + + with open(os.environ['GITHUB_OUTPUT'], 'a') as gh_out: + gh_out.write(f"created_issues_file={file_path}") + + print(f"Result saved to env variable GITHUB_OUTPUT by key created_issues_file") def mute_worker(args): @@ -373,7 +389,7 @@ def mute_worker(args): ) as driver: driver.wait(timeout=10, fail_fast=True) - all_tests = execute_query(driver) + all_tests = execute_query(driver, args.branch) if args.mode == 'update_muted_ya': output_path = args.output_folder os.makedirs(output_path, exist_ok=True) @@ -391,6 +407,7 @@ def mute_worker(args): update_muted_ya_parser = subparsers.add_parser('update_muted_ya', help='create new muted_ya') update_muted_ya_parser.add_argument('--output_folder', default=repo_path, required=False, help='Output folder.') + update_muted_ya_parser.add_argument('--branch', default='main', help='Branch to get history') create_issues_parser = subparsers.add_parser( 'create_issues', @@ -399,7 +416,8 @@ def mute_worker(args): create_issues_parser.add_argument( '--file_path', default=f'{repo_path}/mute_update/flaky.txt', required=False, help='file path' ) + create_issues_parser.add_argument('--branch', default='main', help='Branch to get history') args = parser.parse_args() - mute_worker(args) \ No newline at end of file + mute_worker(args) diff --git a/.github/scripts/tests/generate-summary.py b/.github/scripts/tests/generate-summary.py index 5fd6f20588b8..239f24e4e2eb 100755 --- a/.github/scripts/tests/generate-summary.py +++ b/.github/scripts/tests/generate-summary.py @@ -230,7 +230,7 @@ def render_pm(value, url, diff=None): return text -def render_testlist_html(rows, fn, build_preset): +def render_testlist_html(rows, fn, build_preset, branch): TEMPLATES_PATH = os.path.join(os.path.dirname(__file__), "templates") env = Environment(loader=FileSystemLoader(TEMPLATES_PATH), undefined=StrictUndefined) @@ -273,7 +273,7 @@ def render_testlist_html(rows, fn, build_preset): tests_names_for_history.append(test.full_name) try: - history = get_test_history(tests_names_for_history, last_n_runs, build_preset) + history = get_test_history(tests_names_for_history, last_n_runs, build_preset, branch) except Exception: print(traceback.format_exc()) @@ -308,7 +308,9 @@ def render_testlist_html(rows, fn, build_preset): tests=status_test, has_any_log=has_any_log, history=history, - build_preset=buid_preset_params + build_preset=build_preset, + buid_preset_params=buid_preset_params, + branch=branch ) with open(fn, "w") as fp: @@ -345,7 +347,7 @@ def get_codeowners_for_tests(codeowners_file_path, tests_data): tests_data_with_owners.append(test) -def gen_summary(public_dir, public_dir_url, paths, is_retry: bool, build_preset): +def gen_summary(public_dir, public_dir_url, paths, is_retry: bool, build_preset, branch): summary = TestSummary(is_retry=is_retry) for title, html_fn, path in paths: @@ -359,7 +361,7 @@ def gen_summary(public_dir, public_dir_url, paths, is_retry: bool, build_preset) html_fn = os.path.relpath(html_fn, public_dir) report_url = f"{public_dir_url}/{html_fn}" - render_testlist_html(summary_line.tests, os.path.join(public_dir, html_fn),build_preset) + render_testlist_html(summary_line.tests, os.path.join(public_dir, html_fn),build_preset, branch) summary_line.add_report(html_fn, report_url) summary.add_line(summary_line) @@ -418,6 +420,7 @@ def main(): parser.add_argument("--public_dir_url", required=True) parser.add_argument("--summary_links", required=True) parser.add_argument('--build_preset', default="default-linux-x86-64-relwithdebinfo", required=False) + parser.add_argument('--branch', default="main", required=False) parser.add_argument('--status_report_file', required=False) parser.add_argument('--is_retry', required=True, type=int) parser.add_argument('--is_last_retry', required=True, type=int) @@ -434,7 +437,13 @@ def main(): paths = iter(args.args) title_path = list(zip(paths, paths, paths)) - summary = gen_summary(args.public_dir, args.public_dir_url, title_path, is_retry=bool(args.is_retry),build_preset=args.build_preset) + summary = gen_summary(args.public_dir, + args.public_dir_url, + title_path, + is_retry=bool(args.is_retry), + build_preset=args.build_preset, + branch=args.branch + ) write_summary(summary) if summary.is_failed and not args.is_test_result_ignored: diff --git a/.github/scripts/tests/get_muted_tests.py b/.github/scripts/tests/get_muted_tests.py index ff28a7f831aa..ce523706d99d 100755 --- a/.github/scripts/tests/get_muted_tests.py +++ b/.github/scripts/tests/get_muted_tests.py @@ -187,7 +187,7 @@ def mute_applier(args): for test in all_tests: testsuite = to_str(test['suite_folder']) testcase = to_str(test['test_name']) - test['branch'] = 'main' + test['branch'] = args.branch test['is_muted'] = int(mute_check(testsuite, testcase)) upload_muted_tests(all_tests) diff --git a/.github/scripts/tests/get_test_history.py b/.github/scripts/tests/get_test_history.py index 06d4c323725e..a3b2e32146b8 100644 --- a/.github/scripts/tests/get_test_history.py +++ b/.github/scripts/tests/get_test_history.py @@ -16,7 +16,7 @@ DATABASE_PATH = config["QA_DB"]["DATABASE_PATH"] -def get_test_history(test_names_array, last_n_runs_of_test_amount, build_type): +def get_test_history(test_names_array, last_n_runs_of_test_amount, build_type, branch): if "CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS" not in os.environ: print( "Error: Env variable CI_YDB_SERVICE_ACCOUNT_KEY_FILE_CREDENTIALS is missing, skipping" @@ -48,33 +48,64 @@ def get_test_history(test_names_array, last_n_runs_of_test_amount, build_type): DECLARE $test_names AS List; DECLARE $rn_max AS Int32; DECLARE $build_type AS Utf8; - - $test_names=[{','.join("'{0}'".format(x) for x in test_names_batch)}]; + DECLARE $branch AS Utf8; + + $test_names = [{','.join("'{0}'".format(x) for x in test_names_batch)}]; $rn_max = {last_n_runs_of_test_amount}; $build_type = '{build_type}'; + $branch = '{branch}'; - $tests=( + -- Оптимизированный запрос с учетом особенностей YDB + $filtered_tests = ( SELECT - suite_folder ||'/' || test_name as full_name,test_name,build_type, commit, branch, run_timestamp, status, status_description, + suite_folder || '/' || test_name AS full_name, + test_name, + build_type, + commit, + branch, + run_timestamp, + status, + status_description, + job_id, + job_name, ROW_NUMBER() OVER (PARTITION BY test_name ORDER BY run_timestamp DESC) AS rn FROM - `test_results/test_runs_column` - where job_name in ( - 'Nightly-run', - 'Regression-run', - 'Regression-whitelist-run', - 'Postcommit_relwithdebinfo', - 'Postcommit_asan' - ) - and build_type = $build_type - and suite_folder ||'/' || test_name in $test_names - and status != 'skipped' + `test_results/test_runs_column` AS t + WHERE + t.build_type = $build_type + AND t.branch = $branch + AND t.job_name IN ( + 'Nightly-run', + 'Regression-run', + 'Regression-whitelist-run', + 'Postcommit_relwithdebinfo', + 'Postcommit_asan' + ) + AND t.status != 'skipped' + AND suite_folder || '/' || test_name IN $test_names ); - select full_name,test_name,build_type, commit, branch, run_timestamp, status, status_description,rn - from $tests - WHERE rn <= $rn_max - ORDER BY test_name, run_timestamp; + -- Финальный запрос с ограничением по количеству запусков + SELECT + full_name, + test_name, + build_type, + commit, + branch, + run_timestamp, + status, + status_description, + job_id, + job_name, + rn + FROM + $filtered_tests + WHERE + rn <= $rn_max + ORDER BY + test_name, + run_timestamp; + """ query = ydb.ScanQuery(history_query, {}) it = driver.table_client.scan_query(query) @@ -92,10 +123,13 @@ def get_test_history(test_names_array, last_n_runs_of_test_amount, build_type): results[row["full_name"].decode("utf-8")] = {} results[row["full_name"].decode("utf-8")][row["run_timestamp"]] = { + "branch": row["branch"], "status": row["status"], "commit": row["commit"], "datetime": datetime.datetime.fromtimestamp(int(row["run_timestamp"] / 1000000)).strftime("%H:%m %B %d %Y"), - "status_description": row["status_description"], + "status_description": row["status_description"].replace(';;','\n'), + "job_id": row["job_id"], + "job_name": row["job_name"] } end_time = time.time() print( @@ -104,4 +138,4 @@ def get_test_history(test_names_array, last_n_runs_of_test_amount, build_type): if __name__ == "__main__": - get_test_history(test_names_array, last_n_runs_of_test_amount, build_type) + get_test_history(test_names_array, last_n_runs_of_test_amount, build_type, branch) diff --git a/.github/scripts/tests/templates/summary.html b/.github/scripts/tests/templates/summary.html index a595d1b7e233..e21a31e54b65 100644 --- a/.github/scripts/tests/templates/summary.html +++ b/.github/scripts/tests/templates/summary.html @@ -321,6 +321,60 @@ overflow: auto; } + /* Стили для модального окна */ + #errorModal { + display: none; + position: fixed; + z-index: 1000; + left: 0; + top: 0; + width: 100%; + height: 100%; + overflow: auto; + background-color: rgba(0,0,0,0.5); + } + + .modal-content { + background-color: #fefefe; + margin: 5% auto; + padding: 20px; + border: 1px solid #888; + width: 80%; + border-radius: 5px; + max-height: 80vh; + overflow-y: auto; + } + + .close-modal { + color: #aaa; + float: right; + font-size: 28px; + font-weight: bold; + cursor: pointer; + } + + .modal-header { + margin-bottom: 15px; + padding-bottom: 10px; + border-bottom: 1px solid #eee; + font-size: smaller; + } + + .modal-info { + font-size: small; + margin-bottom: 15px; + line-height: 1.5; + } + + .modal-info-item { + margin-bottom: 5px; + } + + .modal-info-label { + font-weight: bold; + display: inline-block; + width: 80px; + }
\ No newline at end of file +YDB Monitoring
\ No newline at end of file diff --git a/ydb/core/viewer/monitoring/json.worker.js b/ydb/core/viewer/monitoring/json.worker.js index 42d921d50fa1..368506b1ca06 100644 --- a/ydb/core/viewer/monitoring/json.worker.js +++ b/ydb/core/viewer/monitoring/json.worker.js @@ -1,2 +1,2 @@ /*! For license information please see json.worker.js.LICENSE.txt */ -(()=>{var e={9861:(e,t,n)=>{"use strict";function r(e,t,n=(e,t)=>e===t){if(e===t)return!0;if(!e||!t)return!1;if(e.length!==t.length)return!1;for(let r=0,i=e.length;re){const n=new Set;return e.filter((e=>{const r=t(e);return!n.has(r)&&(n.add(r),!0)}))}function l(e,t){return e.length>0?e[0]:t}function c(e,t,n){const r=e.slice(0,t),i=e.slice(t);return r.concat(n,i)}function h(e,t){for(const n of t)e.push(n)}var u;function d(e,t){return(n,r)=>t(e(n),e(r))}n.d(t,{E4:()=>h,Fy:()=>l,Hw:()=>f,U9:()=>g,VE:()=>d,aI:()=>r,c1:()=>p,dM:()=>a,j3:()=>m,kj:()=>o,n:()=>i,nK:()=>c,pN:()=>s}),function(e){e.isLessThan=function(e){return e<0},e.isLessThanOrEqual=function(e){return e<=0},e.isGreaterThan=function(e){return e>0},e.isNeitherLessOrGreaterThan=function(e){return 0===e},e.greaterThan=1,e.lessThan=-1,e.neitherLessOrGreaterThan=0}(u||(u={}));const g=(e,t)=>e-t;function f(e){return(t,n)=>-e(t,n)}class m{constructor(e){this.items=e,this.firstIdx=0,this.lastIdx=this.items.length-1}get length(){return this.lastIdx-this.firstIdx+1}takeWhile(e){let t=this.firstIdx;for(;t=0&&e(this.items[t]);)t--;const n=t===this.lastIdx?null:this.items.slice(t+1,this.lastIdx+1);return this.lastIdx=t,n}peek(){if(0!==this.length)return this.items[this.firstIdx]}dequeue(){const e=this.items[this.firstIdx];return this.firstIdx++,e}takeCount(e){const t=this.items.slice(this.firstIdx,this.firstIdx+e);return this.firstIdx+=e,t}}class p{static{this.empty=new p((e=>{}))}constructor(e){this.iterate=e}toArray(){const e=[];return this.iterate((t=>(e.push(t),!0))),e}filter(e){return new p((t=>this.iterate((n=>!e(n)||t(n)))))}map(e){return new p((t=>this.iterate((n=>t(e(n))))))}findLast(e){let t;return this.iterate((n=>(e(n)&&(t=n),!0))),t}findLastMaxBy(e){let t,n=!0;return this.iterate((r=>((n||u.isGreaterThan(e(r,t)))&&(n=!1,t=r),!0))),t}}},6041:(e,t,n)=>{"use strict";function r(e,t){const n=function(e,t,n=e.length-1){for(let r=n;r>=0;r--){if(t(e[r]))return r}return-1}(e,t);if(-1!==n)return e[n]}function i(e,t){const n=s(e,t);return-1===n?void 0:e[n]}function s(e,t,n=0,r=e.length){let i=n,s=r;for(;ir,XP:()=>o,hw:()=>a,iM:()=>s,lx:()=>i,vJ:()=>l});class l{static{this.assertInvariants=!1}constructor(e){this._array=e,this._findLastMonotonousLastIdx=0}findLastMonotonous(e){if(l.assertInvariants){if(this._prevFindLastPredicate)for(const t of this._array)if(this._prevFindLastPredicate(t)&&!e(t))throw new Error("MonotonousArray: current predicate must be weaker than (or equal to) the previous predicate.");this._prevFindLastPredicate=e}const t=s(this._array,e,this._findLastMonotonousLastIdx);return this._findLastMonotonousLastIdx=t+1,-1===t?void 0:this._array[t]}}},6782:(e,t,n)=>{"use strict";n.d(t,{Ft:()=>o,Xo:()=>a,ok:()=>i,xb:()=>s});var r=n(4383);function i(e,t){if(!e)throw new Error(t?`Assertion failed (${t})`:"Assertion Failed")}function s(e,t="Unreachable"){throw new Error(t)}function o(e){e()||(e(),(0,r.dz)(new r.D7("Assertion Failed")))}function a(e,t){let n=0;for(;n{"use strict";n.d(t,{vb:()=>l,uC:()=>c,Qg:()=>a,$6:()=>h});n(8447);var r=n(4383),i=n(1234),s=n(1484),o=n(8067);Symbol("MicrotaskDelay");function a(e){return!!e&&"function"===typeof e.then}class l{constructor(){this.disposable=void 0,this.isDisposed=!1}cancel(){this.disposable?.dispose(),this.disposable=void 0}cancelAndSet(e,t,n=globalThis){if(this.isDisposed)throw new r.D7("Calling 'cancelAndSet' on a disposed IntervalTimer");this.cancel();const i=n.setInterval((()=>{e()}),t);this.disposable=(0,s.s)((()=>{n.clearInterval(i),this.disposable=void 0}))}dispose(){this.cancel(),this.isDisposed=!0}}class c{constructor(e,t){this.timeoutToken=-1,this.runner=e,this.timeout=t,this.timeoutHandler=this.onTimeout.bind(this)}dispose(){this.cancel(),this.runner=null}cancel(){this.isScheduled()&&(clearTimeout(this.timeoutToken),this.timeoutToken=-1)}schedule(e=this.timeout){this.cancel(),this.timeoutToken=setTimeout(this.timeoutHandler,e)}get delay(){return this.timeout}set delay(e){this.timeout=e}isScheduled(){return-1!==this.timeoutToken}onTimeout(){this.timeoutToken=-1,this.runner&&this.doRun()}doRun(){this.runner?.()}}let h,u;u="function"!==typeof globalThis.requestIdleCallback||"function"!==typeof globalThis.cancelIdleCallback?(e,t)=>{(0,o._p)((()=>{if(n)return;const e=Date.now()+15,r={didTimeout:!0,timeRemaining:()=>Math.max(0,e-Date.now())};t(Object.freeze(r))}));let n=!1;return{dispose(){n||(n=!0)}}}:(e,t,n)=>{const r=e.requestIdleCallback(t,"number"===typeof n?{timeout:n}:void 0);let i=!1;return{dispose(){i||(i=!0,e.cancelIdleCallback(r))}}},h=e=>u(globalThis,e);var d;!function(e){e.settled=async function(e){let t;const n=await Promise.all(e.map((e=>e.then((e=>e),(e=>{t||(t=e)})))));if("undefined"!==typeof t)throw t;return n},e.withAsyncBody=function(e){return new Promise((async(t,n)=>{try{await e(t,n)}catch(r){n(r)}}))}}(d||(d={}));class g{static fromArray(e){return new g((t=>{t.emitMany(e)}))}static fromPromise(e){return new g((async t=>{t.emitMany(await e)}))}static fromPromises(e){return new g((async t=>{await Promise.all(e.map((async e=>t.emitOne(await e))))}))}static merge(e){return new g((async t=>{await Promise.all(e.map((async e=>{for await(const n of e)t.emitOne(n)})))}))}static{this.EMPTY=g.fromArray([])}constructor(e,t){this._state=0,this._results=[],this._error=null,this._onReturn=t,this._onStateChanged=new i.vl,queueMicrotask((async()=>{const t={emitOne:e=>this.emitOne(e),emitMany:e=>this.emitMany(e),reject:e=>this.reject(e)};try{await Promise.resolve(e(t)),this.resolve()}catch(n){this.reject(n)}finally{t.emitOne=void 0,t.emitMany=void 0,t.reject=void 0}}))}[Symbol.asyncIterator](){let e=0;return{next:async()=>{for(;;){if(2===this._state)throw this._error;if(e(this._onReturn?.(),{done:!0,value:void 0})}}static map(e,t){return new g((async n=>{for await(const r of e)n.emitOne(t(r))}))}map(e){return g.map(this,e)}static filter(e,t){return new g((async n=>{for await(const r of e)t(r)&&n.emitOne(r)}))}filter(e){return g.filter(this,e)}static coalesce(e){return g.filter(e,(e=>!!e))}coalesce(){return g.coalesce(this)}static async toPromise(e){const t=[];for await(const n of e)t.push(n);return t}toPromise(){return g.toPromise(this)}emitOne(e){0===this._state&&(this._results.push(e),this._onStateChanged.fire())}emitMany(e){0===this._state&&(this._results=this._results.concat(e),this._onStateChanged.fire())}resolve(){0===this._state&&(this._state=1,this._onStateChanged.fire())}reject(e){0===this._state&&(this._state=2,this._error=e,this._onStateChanged.fire())}}},1674:(e,t,n)=>{"use strict";n.d(t,{$l:()=>a,Gs:()=>d,MB:()=>o,Sw:()=>h,bb:()=>c,gN:()=>l,pJ:()=>u});var r=n(1090);const i="undefined"!==typeof Buffer;new r.d((()=>new Uint8Array(256)));let s;class o{static wrap(e){return i&&!Buffer.isBuffer(e)&&(e=Buffer.from(e.buffer,e.byteOffset,e.byteLength)),new o(e)}constructor(e){this.buffer=e,this.byteLength=this.buffer.byteLength}toString(){return i?this.buffer.toString():(s||(s=new TextDecoder),s.decode(this.buffer))}}function a(e,t){return(e[t+0]|0)>>>0|e[t+1]<<8>>>0}function l(e,t,n){e[n+0]=255&t,t>>>=8,e[n+1]=255&t}function c(e,t){return e[t]*2**24+65536*e[t+1]+256*e[t+2]+e[t+3]}function h(e,t,n){e[n+3]=t,t>>>=8,e[n+2]=t,t>>>=8,e[n+1]=t,t>>>=8,e[n]=t}function u(e,t){return e[t]}function d(e,t,n){e[n]=t}},1788:(e,t,n)=>{"use strict";function r(e){return e}n.d(t,{VV:()=>s,o5:()=>i});class i{constructor(e,t){this.lastCache=void 0,this.lastArgKey=void 0,"function"===typeof e?(this._fn=e,this._computeKey=r):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);return this.lastArgKey!==t&&(this.lastArgKey=t,this.lastCache=this._fn(e)),this.lastCache}}class s{get cachedValues(){return this._map}constructor(e,t){this._map=new Map,this._map2=new Map,"function"===typeof e?(this._fn=e,this._computeKey=r):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);if(this._map2.has(t))return this._map2.get(t);const n=this._fn(e);return this._map.set(e,n),this._map2.set(t,n),n}}},8447:(e,t,n)=>{"use strict";n.d(t,{Qi:()=>a});var r=n(1234);const i=Object.freeze((function(e,t){const n=setTimeout(e.bind(t),0);return{dispose(){clearTimeout(n)}}}));var s;!function(e){e.isCancellationToken=function(t){return t===e.None||t===e.Cancelled||(t instanceof o||!(!t||"object"!==typeof t)&&("boolean"===typeof t.isCancellationRequested&&"function"===typeof t.onCancellationRequested))},e.None=Object.freeze({isCancellationRequested:!1,onCancellationRequested:r.Jh.None}),e.Cancelled=Object.freeze({isCancellationRequested:!0,onCancellationRequested:i})}(s||(s={}));class o{constructor(){this._isCancelled=!1,this._emitter=null}cancel(){this._isCancelled||(this._isCancelled=!0,this._emitter&&(this._emitter.fire(void 0),this.dispose()))}get isCancellationRequested(){return this._isCancelled}get onCancellationRequested(){return this._isCancelled?i:(this._emitter||(this._emitter=new r.vl),this._emitter.event)}dispose(){this._emitter&&(this._emitter.dispose(),this._emitter=null)}}class a{constructor(e){this._token=void 0,this._parentListener=void 0,this._parentListener=e&&e.onCancellationRequested(this.cancel,this)}get token(){return this._token||(this._token=new o),this._token}cancel(){this._token?this._token instanceof o&&this._token.cancel():this._token=s.Cancelled}dispose(e=!1){e&&this.cancel(),this._parentListener?.dispose(),this._token?this._token instanceof o&&this._token.dispose():this._token=s.None}}},9493:(e,t,n)=>{"use strict";n.d(t,{W:()=>o});var r=n(631);const i=Object.create(null);function s(e,t){if((0,r.Kg)(t)){const n=i[t];if(void 0===n)throw new Error(`${e} references an unknown codicon: ${t}`);t=n}return i[e]=t,{id:e}}const o={...{add:s("add",6e4),plus:s("plus",6e4),gistNew:s("gist-new",6e4),repoCreate:s("repo-create",6e4),lightbulb:s("lightbulb",60001),lightBulb:s("light-bulb",60001),repo:s("repo",60002),repoDelete:s("repo-delete",60002),gistFork:s("gist-fork",60003),repoForked:s("repo-forked",60003),gitPullRequest:s("git-pull-request",60004),gitPullRequestAbandoned:s("git-pull-request-abandoned",60004),recordKeys:s("record-keys",60005),keyboard:s("keyboard",60005),tag:s("tag",60006),gitPullRequestLabel:s("git-pull-request-label",60006),tagAdd:s("tag-add",60006),tagRemove:s("tag-remove",60006),person:s("person",60007),personFollow:s("person-follow",60007),personOutline:s("person-outline",60007),personFilled:s("person-filled",60007),gitBranch:s("git-branch",60008),gitBranchCreate:s("git-branch-create",60008),gitBranchDelete:s("git-branch-delete",60008),sourceControl:s("source-control",60008),mirror:s("mirror",60009),mirrorPublic:s("mirror-public",60009),star:s("star",60010),starAdd:s("star-add",60010),starDelete:s("star-delete",60010),starEmpty:s("star-empty",60010),comment:s("comment",60011),commentAdd:s("comment-add",60011),alert:s("alert",60012),warning:s("warning",60012),search:s("search",60013),searchSave:s("search-save",60013),logOut:s("log-out",60014),signOut:s("sign-out",60014),logIn:s("log-in",60015),signIn:s("sign-in",60015),eye:s("eye",60016),eyeUnwatch:s("eye-unwatch",60016),eyeWatch:s("eye-watch",60016),circleFilled:s("circle-filled",60017),primitiveDot:s("primitive-dot",60017),closeDirty:s("close-dirty",60017),debugBreakpoint:s("debug-breakpoint",60017),debugBreakpointDisabled:s("debug-breakpoint-disabled",60017),debugHint:s("debug-hint",60017),terminalDecorationSuccess:s("terminal-decoration-success",60017),primitiveSquare:s("primitive-square",60018),edit:s("edit",60019),pencil:s("pencil",60019),info:s("info",60020),issueOpened:s("issue-opened",60020),gistPrivate:s("gist-private",60021),gitForkPrivate:s("git-fork-private",60021),lock:s("lock",60021),mirrorPrivate:s("mirror-private",60021),close:s("close",60022),removeClose:s("remove-close",60022),x:s("x",60022),repoSync:s("repo-sync",60023),sync:s("sync",60023),clone:s("clone",60024),desktopDownload:s("desktop-download",60024),beaker:s("beaker",60025),microscope:s("microscope",60025),vm:s("vm",60026),deviceDesktop:s("device-desktop",60026),file:s("file",60027),fileText:s("file-text",60027),more:s("more",60028),ellipsis:s("ellipsis",60028),kebabHorizontal:s("kebab-horizontal",60028),mailReply:s("mail-reply",60029),reply:s("reply",60029),organization:s("organization",60030),organizationFilled:s("organization-filled",60030),organizationOutline:s("organization-outline",60030),newFile:s("new-file",60031),fileAdd:s("file-add",60031),newFolder:s("new-folder",60032),fileDirectoryCreate:s("file-directory-create",60032),trash:s("trash",60033),trashcan:s("trashcan",60033),history:s("history",60034),clock:s("clock",60034),folder:s("folder",60035),fileDirectory:s("file-directory",60035),symbolFolder:s("symbol-folder",60035),logoGithub:s("logo-github",60036),markGithub:s("mark-github",60036),github:s("github",60036),terminal:s("terminal",60037),console:s("console",60037),repl:s("repl",60037),zap:s("zap",60038),symbolEvent:s("symbol-event",60038),error:s("error",60039),stop:s("stop",60039),variable:s("variable",60040),symbolVariable:s("symbol-variable",60040),array:s("array",60042),symbolArray:s("symbol-array",60042),symbolModule:s("symbol-module",60043),symbolPackage:s("symbol-package",60043),symbolNamespace:s("symbol-namespace",60043),symbolObject:s("symbol-object",60043),symbolMethod:s("symbol-method",60044),symbolFunction:s("symbol-function",60044),symbolConstructor:s("symbol-constructor",60044),symbolBoolean:s("symbol-boolean",60047),symbolNull:s("symbol-null",60047),symbolNumeric:s("symbol-numeric",60048),symbolNumber:s("symbol-number",60048),symbolStructure:s("symbol-structure",60049),symbolStruct:s("symbol-struct",60049),symbolParameter:s("symbol-parameter",60050),symbolTypeParameter:s("symbol-type-parameter",60050),symbolKey:s("symbol-key",60051),symbolText:s("symbol-text",60051),symbolReference:s("symbol-reference",60052),goToFile:s("go-to-file",60052),symbolEnum:s("symbol-enum",60053),symbolValue:s("symbol-value",60053),symbolRuler:s("symbol-ruler",60054),symbolUnit:s("symbol-unit",60054),activateBreakpoints:s("activate-breakpoints",60055),archive:s("archive",60056),arrowBoth:s("arrow-both",60057),arrowDown:s("arrow-down",60058),arrowLeft:s("arrow-left",60059),arrowRight:s("arrow-right",60060),arrowSmallDown:s("arrow-small-down",60061),arrowSmallLeft:s("arrow-small-left",60062),arrowSmallRight:s("arrow-small-right",60063),arrowSmallUp:s("arrow-small-up",60064),arrowUp:s("arrow-up",60065),bell:s("bell",60066),bold:s("bold",60067),book:s("book",60068),bookmark:s("bookmark",60069),debugBreakpointConditionalUnverified:s("debug-breakpoint-conditional-unverified",60070),debugBreakpointConditional:s("debug-breakpoint-conditional",60071),debugBreakpointConditionalDisabled:s("debug-breakpoint-conditional-disabled",60071),debugBreakpointDataUnverified:s("debug-breakpoint-data-unverified",60072),debugBreakpointData:s("debug-breakpoint-data",60073),debugBreakpointDataDisabled:s("debug-breakpoint-data-disabled",60073),debugBreakpointLogUnverified:s("debug-breakpoint-log-unverified",60074),debugBreakpointLog:s("debug-breakpoint-log",60075),debugBreakpointLogDisabled:s("debug-breakpoint-log-disabled",60075),briefcase:s("briefcase",60076),broadcast:s("broadcast",60077),browser:s("browser",60078),bug:s("bug",60079),calendar:s("calendar",60080),caseSensitive:s("case-sensitive",60081),check:s("check",60082),checklist:s("checklist",60083),chevronDown:s("chevron-down",60084),chevronLeft:s("chevron-left",60085),chevronRight:s("chevron-right",60086),chevronUp:s("chevron-up",60087),chromeClose:s("chrome-close",60088),chromeMaximize:s("chrome-maximize",60089),chromeMinimize:s("chrome-minimize",60090),chromeRestore:s("chrome-restore",60091),circleOutline:s("circle-outline",60092),circle:s("circle",60092),debugBreakpointUnverified:s("debug-breakpoint-unverified",60092),terminalDecorationIncomplete:s("terminal-decoration-incomplete",60092),circleSlash:s("circle-slash",60093),circuitBoard:s("circuit-board",60094),clearAll:s("clear-all",60095),clippy:s("clippy",60096),closeAll:s("close-all",60097),cloudDownload:s("cloud-download",60098),cloudUpload:s("cloud-upload",60099),code:s("code",60100),collapseAll:s("collapse-all",60101),colorMode:s("color-mode",60102),commentDiscussion:s("comment-discussion",60103),creditCard:s("credit-card",60105),dash:s("dash",60108),dashboard:s("dashboard",60109),database:s("database",60110),debugContinue:s("debug-continue",60111),debugDisconnect:s("debug-disconnect",60112),debugPause:s("debug-pause",60113),debugRestart:s("debug-restart",60114),debugStart:s("debug-start",60115),debugStepInto:s("debug-step-into",60116),debugStepOut:s("debug-step-out",60117),debugStepOver:s("debug-step-over",60118),debugStop:s("debug-stop",60119),debug:s("debug",60120),deviceCameraVideo:s("device-camera-video",60121),deviceCamera:s("device-camera",60122),deviceMobile:s("device-mobile",60123),diffAdded:s("diff-added",60124),diffIgnored:s("diff-ignored",60125),diffModified:s("diff-modified",60126),diffRemoved:s("diff-removed",60127),diffRenamed:s("diff-renamed",60128),diff:s("diff",60129),diffSidebyside:s("diff-sidebyside",60129),discard:s("discard",60130),editorLayout:s("editor-layout",60131),emptyWindow:s("empty-window",60132),exclude:s("exclude",60133),extensions:s("extensions",60134),eyeClosed:s("eye-closed",60135),fileBinary:s("file-binary",60136),fileCode:s("file-code",60137),fileMedia:s("file-media",60138),filePdf:s("file-pdf",60139),fileSubmodule:s("file-submodule",60140),fileSymlinkDirectory:s("file-symlink-directory",60141),fileSymlinkFile:s("file-symlink-file",60142),fileZip:s("file-zip",60143),files:s("files",60144),filter:s("filter",60145),flame:s("flame",60146),foldDown:s("fold-down",60147),foldUp:s("fold-up",60148),fold:s("fold",60149),folderActive:s("folder-active",60150),folderOpened:s("folder-opened",60151),gear:s("gear",60152),gift:s("gift",60153),gistSecret:s("gist-secret",60154),gist:s("gist",60155),gitCommit:s("git-commit",60156),gitCompare:s("git-compare",60157),compareChanges:s("compare-changes",60157),gitMerge:s("git-merge",60158),githubAction:s("github-action",60159),githubAlt:s("github-alt",60160),globe:s("globe",60161),grabber:s("grabber",60162),graph:s("graph",60163),gripper:s("gripper",60164),heart:s("heart",60165),home:s("home",60166),horizontalRule:s("horizontal-rule",60167),hubot:s("hubot",60168),inbox:s("inbox",60169),issueReopened:s("issue-reopened",60171),issues:s("issues",60172),italic:s("italic",60173),jersey:s("jersey",60174),json:s("json",60175),kebabVertical:s("kebab-vertical",60176),key:s("key",60177),law:s("law",60178),lightbulbAutofix:s("lightbulb-autofix",60179),linkExternal:s("link-external",60180),link:s("link",60181),listOrdered:s("list-ordered",60182),listUnordered:s("list-unordered",60183),liveShare:s("live-share",60184),loading:s("loading",60185),location:s("location",60186),mailRead:s("mail-read",60187),mail:s("mail",60188),markdown:s("markdown",60189),megaphone:s("megaphone",60190),mention:s("mention",60191),milestone:s("milestone",60192),gitPullRequestMilestone:s("git-pull-request-milestone",60192),mortarBoard:s("mortar-board",60193),move:s("move",60194),multipleWindows:s("multiple-windows",60195),mute:s("mute",60196),noNewline:s("no-newline",60197),note:s("note",60198),octoface:s("octoface",60199),openPreview:s("open-preview",60200),package:s("package",60201),paintcan:s("paintcan",60202),pin:s("pin",60203),play:s("play",60204),run:s("run",60204),plug:s("plug",60205),preserveCase:s("preserve-case",60206),preview:s("preview",60207),project:s("project",60208),pulse:s("pulse",60209),question:s("question",60210),quote:s("quote",60211),radioTower:s("radio-tower",60212),reactions:s("reactions",60213),references:s("references",60214),refresh:s("refresh",60215),regex:s("regex",60216),remoteExplorer:s("remote-explorer",60217),remote:s("remote",60218),remove:s("remove",60219),replaceAll:s("replace-all",60220),replace:s("replace",60221),repoClone:s("repo-clone",60222),repoForcePush:s("repo-force-push",60223),repoPull:s("repo-pull",60224),repoPush:s("repo-push",60225),report:s("report",60226),requestChanges:s("request-changes",60227),rocket:s("rocket",60228),rootFolderOpened:s("root-folder-opened",60229),rootFolder:s("root-folder",60230),rss:s("rss",60231),ruby:s("ruby",60232),saveAll:s("save-all",60233),saveAs:s("save-as",60234),save:s("save",60235),screenFull:s("screen-full",60236),screenNormal:s("screen-normal",60237),searchStop:s("search-stop",60238),server:s("server",60240),settingsGear:s("settings-gear",60241),settings:s("settings",60242),shield:s("shield",60243),smiley:s("smiley",60244),sortPrecedence:s("sort-precedence",60245),splitHorizontal:s("split-horizontal",60246),splitVertical:s("split-vertical",60247),squirrel:s("squirrel",60248),starFull:s("star-full",60249),starHalf:s("star-half",60250),symbolClass:s("symbol-class",60251),symbolColor:s("symbol-color",60252),symbolConstant:s("symbol-constant",60253),symbolEnumMember:s("symbol-enum-member",60254),symbolField:s("symbol-field",60255),symbolFile:s("symbol-file",60256),symbolInterface:s("symbol-interface",60257),symbolKeyword:s("symbol-keyword",60258),symbolMisc:s("symbol-misc",60259),symbolOperator:s("symbol-operator",60260),symbolProperty:s("symbol-property",60261),wrench:s("wrench",60261),wrenchSubaction:s("wrench-subaction",60261),symbolSnippet:s("symbol-snippet",60262),tasklist:s("tasklist",60263),telescope:s("telescope",60264),textSize:s("text-size",60265),threeBars:s("three-bars",60266),thumbsdown:s("thumbsdown",60267),thumbsup:s("thumbsup",60268),tools:s("tools",60269),triangleDown:s("triangle-down",60270),triangleLeft:s("triangle-left",60271),triangleRight:s("triangle-right",60272),triangleUp:s("triangle-up",60273),twitter:s("twitter",60274),unfold:s("unfold",60275),unlock:s("unlock",60276),unmute:s("unmute",60277),unverified:s("unverified",60278),verified:s("verified",60279),versions:s("versions",60280),vmActive:s("vm-active",60281),vmOutline:s("vm-outline",60282),vmRunning:s("vm-running",60283),watch:s("watch",60284),whitespace:s("whitespace",60285),wholeWord:s("whole-word",60286),window:s("window",60287),wordWrap:s("word-wrap",60288),zoomIn:s("zoom-in",60289),zoomOut:s("zoom-out",60290),listFilter:s("list-filter",60291),listFlat:s("list-flat",60292),listSelection:s("list-selection",60293),selection:s("selection",60293),listTree:s("list-tree",60294),debugBreakpointFunctionUnverified:s("debug-breakpoint-function-unverified",60295),debugBreakpointFunction:s("debug-breakpoint-function",60296),debugBreakpointFunctionDisabled:s("debug-breakpoint-function-disabled",60296),debugStackframeActive:s("debug-stackframe-active",60297),circleSmallFilled:s("circle-small-filled",60298),debugStackframeDot:s("debug-stackframe-dot",60298),terminalDecorationMark:s("terminal-decoration-mark",60298),debugStackframe:s("debug-stackframe",60299),debugStackframeFocused:s("debug-stackframe-focused",60299),debugBreakpointUnsupported:s("debug-breakpoint-unsupported",60300),symbolString:s("symbol-string",60301),debugReverseContinue:s("debug-reverse-continue",60302),debugStepBack:s("debug-step-back",60303),debugRestartFrame:s("debug-restart-frame",60304),debugAlt:s("debug-alt",60305),callIncoming:s("call-incoming",60306),callOutgoing:s("call-outgoing",60307),menu:s("menu",60308),expandAll:s("expand-all",60309),feedback:s("feedback",60310),gitPullRequestReviewer:s("git-pull-request-reviewer",60310),groupByRefType:s("group-by-ref-type",60311),ungroupByRefType:s("ungroup-by-ref-type",60312),account:s("account",60313),gitPullRequestAssignee:s("git-pull-request-assignee",60313),bellDot:s("bell-dot",60314),debugConsole:s("debug-console",60315),library:s("library",60316),output:s("output",60317),runAll:s("run-all",60318),syncIgnored:s("sync-ignored",60319),pinned:s("pinned",60320),githubInverted:s("github-inverted",60321),serverProcess:s("server-process",60322),serverEnvironment:s("server-environment",60323),pass:s("pass",60324),issueClosed:s("issue-closed",60324),stopCircle:s("stop-circle",60325),playCircle:s("play-circle",60326),record:s("record",60327),debugAltSmall:s("debug-alt-small",60328),vmConnect:s("vm-connect",60329),cloud:s("cloud",60330),merge:s("merge",60331),export:s("export",60332),graphLeft:s("graph-left",60333),magnet:s("magnet",60334),notebook:s("notebook",60335),redo:s("redo",60336),checkAll:s("check-all",60337),pinnedDirty:s("pinned-dirty",60338),passFilled:s("pass-filled",60339),circleLargeFilled:s("circle-large-filled",60340),circleLarge:s("circle-large",60341),circleLargeOutline:s("circle-large-outline",60341),combine:s("combine",60342),gather:s("gather",60342),table:s("table",60343),variableGroup:s("variable-group",60344),typeHierarchy:s("type-hierarchy",60345),typeHierarchySub:s("type-hierarchy-sub",60346),typeHierarchySuper:s("type-hierarchy-super",60347),gitPullRequestCreate:s("git-pull-request-create",60348),runAbove:s("run-above",60349),runBelow:s("run-below",60350),notebookTemplate:s("notebook-template",60351),debugRerun:s("debug-rerun",60352),workspaceTrusted:s("workspace-trusted",60353),workspaceUntrusted:s("workspace-untrusted",60354),workspaceUnknown:s("workspace-unknown",60355),terminalCmd:s("terminal-cmd",60356),terminalDebian:s("terminal-debian",60357),terminalLinux:s("terminal-linux",60358),terminalPowershell:s("terminal-powershell",60359),terminalTmux:s("terminal-tmux",60360),terminalUbuntu:s("terminal-ubuntu",60361),terminalBash:s("terminal-bash",60362),arrowSwap:s("arrow-swap",60363),copy:s("copy",60364),personAdd:s("person-add",60365),filterFilled:s("filter-filled",60366),wand:s("wand",60367),debugLineByLine:s("debug-line-by-line",60368),inspect:s("inspect",60369),layers:s("layers",60370),layersDot:s("layers-dot",60371),layersActive:s("layers-active",60372),compass:s("compass",60373),compassDot:s("compass-dot",60374),compassActive:s("compass-active",60375),azure:s("azure",60376),issueDraft:s("issue-draft",60377),gitPullRequestClosed:s("git-pull-request-closed",60378),gitPullRequestDraft:s("git-pull-request-draft",60379),debugAll:s("debug-all",60380),debugCoverage:s("debug-coverage",60381),runErrors:s("run-errors",60382),folderLibrary:s("folder-library",60383),debugContinueSmall:s("debug-continue-small",60384),beakerStop:s("beaker-stop",60385),graphLine:s("graph-line",60386),graphScatter:s("graph-scatter",60387),pieChart:s("pie-chart",60388),bracket:s("bracket",60175),bracketDot:s("bracket-dot",60389),bracketError:s("bracket-error",60390),lockSmall:s("lock-small",60391),azureDevops:s("azure-devops",60392),verifiedFilled:s("verified-filled",60393),newline:s("newline",60394),layout:s("layout",60395),layoutActivitybarLeft:s("layout-activitybar-left",60396),layoutActivitybarRight:s("layout-activitybar-right",60397),layoutPanelLeft:s("layout-panel-left",60398),layoutPanelCenter:s("layout-panel-center",60399),layoutPanelJustify:s("layout-panel-justify",60400),layoutPanelRight:s("layout-panel-right",60401),layoutPanel:s("layout-panel",60402),layoutSidebarLeft:s("layout-sidebar-left",60403),layoutSidebarRight:s("layout-sidebar-right",60404),layoutStatusbar:s("layout-statusbar",60405),layoutMenubar:s("layout-menubar",60406),layoutCentered:s("layout-centered",60407),target:s("target",60408),indent:s("indent",60409),recordSmall:s("record-small",60410),errorSmall:s("error-small",60411),terminalDecorationError:s("terminal-decoration-error",60411),arrowCircleDown:s("arrow-circle-down",60412),arrowCircleLeft:s("arrow-circle-left",60413),arrowCircleRight:s("arrow-circle-right",60414),arrowCircleUp:s("arrow-circle-up",60415),layoutSidebarRightOff:s("layout-sidebar-right-off",60416),layoutPanelOff:s("layout-panel-off",60417),layoutSidebarLeftOff:s("layout-sidebar-left-off",60418),blank:s("blank",60419),heartFilled:s("heart-filled",60420),map:s("map",60421),mapHorizontal:s("map-horizontal",60421),foldHorizontal:s("fold-horizontal",60421),mapFilled:s("map-filled",60422),mapHorizontalFilled:s("map-horizontal-filled",60422),foldHorizontalFilled:s("fold-horizontal-filled",60422),circleSmall:s("circle-small",60423),bellSlash:s("bell-slash",60424),bellSlashDot:s("bell-slash-dot",60425),commentUnresolved:s("comment-unresolved",60426),gitPullRequestGoToChanges:s("git-pull-request-go-to-changes",60427),gitPullRequestNewChanges:s("git-pull-request-new-changes",60428),searchFuzzy:s("search-fuzzy",60429),commentDraft:s("comment-draft",60430),send:s("send",60431),sparkle:s("sparkle",60432),insert:s("insert",60433),mic:s("mic",60434),thumbsdownFilled:s("thumbsdown-filled",60435),thumbsupFilled:s("thumbsup-filled",60436),coffee:s("coffee",60437),snake:s("snake",60438),game:s("game",60439),vr:s("vr",60440),chip:s("chip",60441),piano:s("piano",60442),music:s("music",60443),micFilled:s("mic-filled",60444),repoFetch:s("repo-fetch",60445),copilot:s("copilot",60446),lightbulbSparkle:s("lightbulb-sparkle",60447),robot:s("robot",60448),sparkleFilled:s("sparkle-filled",60449),diffSingle:s("diff-single",60450),diffMultiple:s("diff-multiple",60451),surroundWith:s("surround-with",60452),share:s("share",60453),gitStash:s("git-stash",60454),gitStashApply:s("git-stash-apply",60455),gitStashPop:s("git-stash-pop",60456),vscode:s("vscode",60457),vscodeInsiders:s("vscode-insiders",60458),codeOss:s("code-oss",60459),runCoverage:s("run-coverage",60460),runAllCoverage:s("run-all-coverage",60461),coverage:s("coverage",60462),githubProject:s("github-project",60463),mapVertical:s("map-vertical",60464),foldVertical:s("fold-vertical",60464),mapVerticalFilled:s("map-vertical-filled",60465),foldVerticalFilled:s("fold-vertical-filled",60465),goToSearch:s("go-to-search",60466),percentage:s("percentage",60467),sortPercentage:s("sort-percentage",60467),attach:s("attach",60468)},...{dialogError:s("dialog-error","error"),dialogWarning:s("dialog-warning","warning"),dialogInfo:s("dialog-info","info"),dialogClose:s("dialog-close","close"),treeItemExpanded:s("tree-item-expanded","chevron-down"),treeFilterOnTypeOn:s("tree-filter-on-type-on","list-filter"),treeFilterOnTypeOff:s("tree-filter-on-type-off","list-selection"),treeFilterClear:s("tree-filter-clear","close"),treeItemLoading:s("tree-item-loading","loading"),menuSelection:s("menu-selection","check"),menuSubmenu:s("menu-submenu","chevron-right"),menuBarMore:s("menubar-more","more"),scrollbarButtonLeft:s("scrollbar-button-left","triangle-left"),scrollbarButtonRight:s("scrollbar-button-right","triangle-right"),scrollbarButtonUp:s("scrollbar-button-up","triangle-up"),scrollbarButtonDown:s("scrollbar-button-down","triangle-down"),toolBarMore:s("toolbar-more","more"),quickInputBack:s("quick-input-back","arrow-left"),dropDownButton:s("drop-down-button",60084),symbolCustomColor:s("symbol-customcolor",60252),exportIcon:s("export",60332),workspaceUnspecified:s("workspace-unspecified",60355),newLine:s("newline",60394),thumbsDownFilled:s("thumbsdown-filled",60435),thumbsUpFilled:s("thumbsup-filled",60436),gitFetch:s("git-fetch",60445),lightbulbSparkleAutofix:s("lightbulb-sparkle-autofix",60447),debugBreakpointPending:s("debug-breakpoint-pending",60377)}}},7661:(e,t,n)=>{"use strict";function r(e,t){const n=Math.pow(10,t);return Math.round(e*n)/n}n.d(t,{Q1:()=>a,bU:()=>i,hB:()=>s});class i{constructor(e,t,n,i=1){this._rgbaBrand=void 0,this.r=0|Math.min(255,Math.max(0,e)),this.g=0|Math.min(255,Math.max(0,t)),this.b=0|Math.min(255,Math.max(0,n)),this.a=r(Math.max(Math.min(1,i),0),3)}static equals(e,t){return e.r===t.r&&e.g===t.g&&e.b===t.b&&e.a===t.a}}class s{constructor(e,t,n,i){this._hslaBrand=void 0,this.h=0|Math.max(Math.min(360,e),0),this.s=r(Math.max(Math.min(1,t),0),3),this.l=r(Math.max(Math.min(1,n),0),3),this.a=r(Math.max(Math.min(1,i),0),3)}static equals(e,t){return e.h===t.h&&e.s===t.s&&e.l===t.l&&e.a===t.a}static fromRGBA(e){const t=e.r/255,n=e.g/255,r=e.b/255,i=e.a,o=Math.max(t,n,r),a=Math.min(t,n,r);let l=0,c=0;const h=(a+o)/2,u=o-a;if(u>0){switch(c=Math.min(h<=.5?u/(2*h):u/(2-2*h),1),o){case t:l=(n-r)/u+(n1&&(n-=1),n<1/6?e+6*(t-e)*n:n<.5?t:n<2/3?e+(t-e)*(2/3-n)*6:e}static toRGBA(e){const t=e.h/360,{s:n,l:r,a:o}=e;let a,l,c;if(0===n)a=l=c=r;else{const e=r<.5?r*(1+n):r+n-r*n,i=2*r-e;a=s._hue2rgb(i,e,t+1/3),l=s._hue2rgb(i,e,t),c=s._hue2rgb(i,e,t-1/3)}return new i(Math.round(255*a),Math.round(255*l),Math.round(255*c),o)}}class o{constructor(e,t,n,i){this._hsvaBrand=void 0,this.h=0|Math.max(Math.min(360,e),0),this.s=r(Math.max(Math.min(1,t),0),3),this.v=r(Math.max(Math.min(1,n),0),3),this.a=r(Math.max(Math.min(1,i),0),3)}static equals(e,t){return e.h===t.h&&e.s===t.s&&e.v===t.v&&e.a===t.a}static fromRGBA(e){const t=e.r/255,n=e.g/255,r=e.b/255,i=Math.max(t,n,r),s=i-Math.min(t,n,r),a=0===i?0:s/i;let l;return l=0===s?0:i===t?((n-r)/s%6+6)%6:i===n?(r-t)/s+2:(t-n)/s+4,new o(Math.round(60*l),a,i,e.a)}static toRGBA(e){const{h:t,s:n,v:r,a:s}=e,o=r*n,a=o*(1-Math.abs(t/60%2-1)),l=r-o;let[c,h,u]=[0,0,0];return t<60?(c=o,h=a):t<120?(c=a,h=o):t<180?(h=o,u=a):t<240?(h=a,u=o):t<300?(c=a,u=o):t<=360&&(c=o,u=a),c=Math.round(255*(c+l)),h=Math.round(255*(h+l)),u=Math.round(255*(u+l)),new i(c,h,u,s)}}class a{static fromHex(e){return a.Format.CSS.parseHex(e)||a.red}static equals(e,t){return!e&&!t||!(!e||!t)&&e.equals(t)}get hsla(){return this._hsla?this._hsla:s.fromRGBA(this.rgba)}get hsva(){return this._hsva?this._hsva:o.fromRGBA(this.rgba)}constructor(e){if(!e)throw new Error("Color needs a value");if(e instanceof i)this.rgba=e;else if(e instanceof s)this._hsla=e,this.rgba=s.toRGBA(e);else{if(!(e instanceof o))throw new Error("Invalid color ctor argument");this._hsva=e,this.rgba=o.toRGBA(e)}}equals(e){return!!e&&i.equals(this.rgba,e.rgba)&&s.equals(this.hsla,e.hsla)&&o.equals(this.hsva,e.hsva)}getRelativeLuminance(){return r(.2126*a._relativeLuminanceForComponent(this.rgba.r)+.7152*a._relativeLuminanceForComponent(this.rgba.g)+.0722*a._relativeLuminanceForComponent(this.rgba.b),4)}static _relativeLuminanceForComponent(e){const t=e/255;return t<=.03928?t/12.92:Math.pow((t+.055)/1.055,2.4)}isLighter(){return(299*this.rgba.r+587*this.rgba.g+114*this.rgba.b)/1e3>=128}isLighterThan(e){return this.getRelativeLuminance()>e.getRelativeLuminance()}isDarkerThan(e){return this.getRelativeLuminance(){"use strict";n.d(t,{D7:()=>g,EM:()=>u,Qg:()=>c,cU:()=>s,dz:()=>i,iH:()=>h});const r=new class{constructor(){this.listeners=[],this.unexpectedErrorHandler=function(e){setTimeout((()=>{if(e.stack){if(d.isErrorNoTelemetry(e))throw new d(e.message+"\n\n"+e.stack);throw new Error(e.message+"\n\n"+e.stack)}throw e}),0)}}emit(e){this.listeners.forEach((t=>{t(e)}))}onUnexpectedError(e){this.unexpectedErrorHandler(e),this.emit(e)}onUnexpectedExternalError(e){this.unexpectedErrorHandler(e)}};function i(e){a(e)||r.onUnexpectedError(e)}function s(e){if(e instanceof Error){const{name:t,message:n}=e;return{$isError:!0,name:t,message:n,stack:e.stacktrace||e.stack,noTelemetry:d.isErrorNoTelemetry(e)}}return e}const o="Canceled";function a(e){return e instanceof l||e instanceof Error&&e.name===o&&e.message===o}class l extends Error{constructor(){super(o),this.name=this.message}}function c(e){return e?new Error(`Illegal argument: ${e}`):new Error("Illegal argument")}function h(e){return e?new Error(`Illegal state: ${e}`):new Error("Illegal state")}class u extends Error{constructor(e){super("NotSupported"),e&&(this.message=e)}}class d extends Error{constructor(e){super(e),this.name="CodeExpectedError"}static fromError(e){if(e instanceof d)return e;const t=new d;return t.message=e.message,t.stack=e.stack,t}static isErrorNoTelemetry(e){return"CodeExpectedError"===e.name}}class g extends Error{constructor(e){super(e||"An unexpected bug occurred."),Object.setPrototypeOf(this,g.prototype)}}},1234:(e,t,n)=>{"use strict";n.d(t,{Jh:()=>o,vl:()=>f});var r=n(4383),i=n(1484),s=(n(8925),n(8381));var o;!function(e){function t(e){false}function n(e){return(t,n=null,r)=>{let i,s=!1;return i=e((e=>{if(!s)return i?i.dispose():s=!0,t.call(n,e)}),null,r),s&&i.dispose(),i}}function r(e,t,n){return o(((n,r=null,i)=>e((e=>n.call(r,t(e))),null,i)),n)}function s(e,t,n){return o(((n,r=null,i)=>e((e=>t(e)&&n.call(r,e)),null,i)),n)}function o(e,n){let r;const i={onWillAddFirstListener(){r=e(s.fire,s)},onDidRemoveLastListener(){r?.dispose()}};n||t();const s=new f(i);return n?.add(s),s.event}function a(e,n,r=100,i=!1,s=!1,o,a){let l,c,h,u,d=0;const g={leakWarningThreshold:o,onWillAddFirstListener(){l=e((e=>{d++,c=n(c,e),i&&!h&&(m.fire(c),c=void 0),u=()=>{const e=c;c=void 0,h=void 0,(!i||d>1)&&m.fire(e),d=0},"number"===typeof r?(clearTimeout(h),h=setTimeout(u,r)):void 0===h&&(h=0,queueMicrotask(u))}))},onWillRemoveListener(){s&&d>0&&u?.()},onDidRemoveLastListener(){u=void 0,l.dispose()}};a||t();const m=new f(g);return a?.add(m),m.event}e.None=()=>i.jG.None,e.defer=function(e,t){return a(e,(()=>{}),0,void 0,!0,void 0,t)},e.once=n,e.onceIf=function(t,n){return e.once(e.filter(t,n))},e.map=r,e.forEach=function(e,t,n){return o(((n,r=null,i)=>e((e=>{t(e),n.call(r,e)}),null,i)),n)},e.filter=s,e.signal=function(e){return e},e.any=function(...e){return(t,n=null,r)=>function(e,t){t instanceof Array?t.push(e):t&&t.add(e);return e}((0,i.qE)(...e.map((e=>e((e=>t.call(n,e)))))),r)},e.reduce=function(e,t,n,i){let s=n;return r(e,(e=>(s=t(s,e),s)),i)},e.debounce=a,e.accumulate=function(t,n=0,r){return e.debounce(t,((e,t)=>e?(e.push(t),e):[t]),n,void 0,!0,void 0,r)},e.latch=function(e,t=(e,t)=>e===t,n){let r,i=!0;return s(e,(e=>{const n=i||!t(e,r);return i=!1,r=e,n}),n)},e.split=function(t,n,r){return[e.filter(t,n,r),e.filter(t,(e=>!n(e)),r)]},e.buffer=function(e,t=!1,n=[],r){let i=n.slice(),s=e((e=>{i?i.push(e):a.fire(e)}));r&&r.add(s);const o=()=>{i?.forEach((e=>a.fire(e))),i=null},a=new f({onWillAddFirstListener(){s||(s=e((e=>a.fire(e))),r&&r.add(s))},onDidAddFirstListener(){i&&(t?setTimeout(o):o())},onDidRemoveLastListener(){s&&s.dispose(),s=null}});return r&&r.add(a),a.event},e.chain=function(e,t){return(n,r,i)=>{const s=t(new c);return e((function(e){const t=s.evaluate(e);t!==l&&n.call(r,t)}),void 0,i)}};const l=Symbol("HaltChainable");class c{constructor(){this.steps=[]}map(e){return this.steps.push(e),this}forEach(e){return this.steps.push((t=>(e(t),t))),this}filter(e){return this.steps.push((t=>e(t)?t:l)),this}reduce(e,t){let n=t;return this.steps.push((t=>(n=e(n,t),n))),this}latch(e=(e,t)=>e===t){let t,n=!0;return this.steps.push((r=>{const i=n||!e(r,t);return n=!1,t=r,i?r:l})),this}evaluate(e){for(const t of this.steps)if((e=t(e))===l)break;return e}}e.fromNodeEventEmitter=function(e,t,n=e=>e){const r=(...e)=>i.fire(n(...e)),i=new f({onWillAddFirstListener:()=>e.on(t,r),onDidRemoveLastListener:()=>e.removeListener(t,r)});return i.event},e.fromDOMEventEmitter=function(e,t,n=e=>e){const r=(...e)=>i.fire(n(...e)),i=new f({onWillAddFirstListener:()=>e.addEventListener(t,r),onDidRemoveLastListener:()=>e.removeEventListener(t,r)});return i.event},e.toPromise=function(e){return new Promise((t=>n(e)(t)))},e.fromPromise=function(e){const t=new f;return e.then((e=>{t.fire(e)}),(()=>{t.fire(void 0)})).finally((()=>{t.dispose()})),t.event},e.forward=function(e,t){return e((e=>t.fire(e)))},e.runAndSubscribe=function(e,t,n){return t(n),e((e=>t(e)))};class h{constructor(e,n){this._observable=e,this._counter=0,this._hasChanged=!1;const r={onWillAddFirstListener:()=>{e.addObserver(this),this._observable.reportChanges()},onDidRemoveLastListener:()=>{e.removeObserver(this)}};n||t(),this.emitter=new f(r),n&&n.add(this.emitter)}beginUpdate(e){this._counter++}handlePossibleChange(e){}handleChange(e,t){this._hasChanged=!0}endUpdate(e){this._counter--,0===this._counter&&(this._observable.reportChanges(),this._hasChanged&&(this._hasChanged=!1,this.emitter.fire(this._observable.get())))}}e.fromObservable=function(e,t){return new h(e,t).emitter.event},e.fromObservableLight=function(e){return(t,n,r)=>{let s=0,o=!1;const a={beginUpdate(){s++},endUpdate(){s--,0===s&&(e.reportChanges(),o&&(o=!1,t.call(n)))},handlePossibleChange(){},handleChange(){o=!0}};e.addObserver(a),e.reportChanges();const l={dispose(){e.removeObserver(a)}};return r instanceof i.Cm?r.add(l):Array.isArray(r)&&r.push(l),l}}}(o||(o={}));class a{static{this.all=new Set}static{this._idPool=0}constructor(e){this.listenerCount=0,this.invocationCount=0,this.elapsedOverall=0,this.durations=[],this.name=`${e}_${a._idPool++}`,a.all.add(this)}start(e){this._stopWatch=new s.W,this.listenerCount=e}stop(){if(this._stopWatch){const e=this._stopWatch.elapsed();this.durations.push(e),this.elapsedOverall+=e,this.invocationCount+=1,this._stopWatch=void 0}}}class l{static{this._idPool=1}constructor(e,t,n=(l._idPool++).toString(16).padStart(3,"0")){this._errorHandler=e,this.threshold=t,this.name=n,this._warnCountdown=0}dispose(){this._stacks?.clear()}check(e,t){const n=this.threshold;if(n<=0||t{const t=this._stacks.get(e.value)||0;this._stacks.set(e.value,t-1)}}getMostFrequentStack(){if(!this._stacks)return;let e,t=0;for(const[n,r]of this._stacks)(!e||t{if(this._leakageMon&&this._size>this._leakageMon.threshold**2){const e=`[${this._leakageMon.name}] REFUSES to accept new listeners because it exceeded its threshold by far (${this._size} vs ${this._leakageMon.threshold})`;console.warn(e);const t=this._leakageMon.getMostFrequentStack()??["UNKNOWN stack",-1],n=new u(`${e}. HINT: Stack shows most frequent listener (${t[1]}-times)`,t[0]);return(this._options?.onListenerError||r.dz)(n),i.jG.None}if(this._disposed)return i.jG.None;t&&(e=e.bind(t));const s=new d(e);let o;this._leakageMon&&this._size>=Math.ceil(.2*this._leakageMon.threshold)&&(s.stack=c.create(),o=this._leakageMon.check(s.stack,this._size+1)),this._listeners?this._listeners instanceof d?(this._deliveryQueue??=new m,this._listeners=[this._listeners,s]):this._listeners.push(s):(this._options?.onWillAddFirstListener?.(this),this._listeners=s,this._options?.onDidAddFirstListener?.(this)),this._size++;const a=(0,i.s)((()=>{g?.unregister(a),o?.(),this._removeListener(s)}));if(n instanceof i.Cm?n.add(a):Array.isArray(n)&&n.push(a),g){const e=(new Error).stack.split("\n").slice(2,3).join("\n").trim(),t=/(file:|vscode-file:\/\/vscode-app)?(\/[^:]*:\d+:\d+)/.exec(e);g.register(a,t?.[2]??e,a)}return a},this._event}_removeListener(e){if(this._options?.onWillRemoveListener?.(this),!this._listeners)return;if(1===this._size)return this._listeners=void 0,this._options?.onDidRemoveLastListener?.(this),void(this._size=0);const t=this._listeners,n=t.indexOf(e);if(-1===n)throw console.log("disposed?",this._disposed),console.log("size?",this._size),console.log("arr?",JSON.stringify(this._listeners)),new Error("Attempted to dispose unknown listener");this._size--,t[n]=void 0;const r=this._deliveryQueue.current===this;if(2*this._size<=t.length){let e=0;for(let n=0;n0}}class m{constructor(){this.i=-1,this.end=0}enqueue(e,t,n){this.i=0,this.end=n,this.current=e,this.value=t}reset(){this.i=this.end,this.current=void 0,this.value=void 0}}},9326:(e,t,n)=>{"use strict";n.d(t,{TH:()=>o,Zn:()=>l,_1:()=>c,kb:()=>a});var r=n(8821),i=(n(8067),n(1508));function s(e){return 47===e||92===e}function o(e){return e.replace(/[\\/]/g,r.SA.sep)}function a(e){return-1===e.indexOf("/")&&(e=o(e)),/^[a-zA-Z]:(\/|$)/.test(e)&&(e="/"+e),e}function l(e,t=r.SA.sep){if(!e)return"";const n=e.length,i=e.charCodeAt(0);if(s(i)){if(s(e.charCodeAt(1))&&!s(e.charCodeAt(2))){let r=3;const i=r;for(;re.length)return!1;if(n){if(!(0,i.ns)(e,t))return!1;if(t.length===e.length)return!0;let n=t.length;return t.charAt(t.length-1)===s&&n--,e.charAt(n)===s}return t.charAt(t.length-1)!==s&&(t+=s),0===e.indexOf(t)}function h(e){return e>=65&&e<=90||e>=97&&e<=122}},6958:(e,t,n)=>{"use strict";n.d(t,{YW:()=>A,qg:()=>I});var r=n(1940),i=n(9326),s=n(4320),o=n(8821),a=n(8067),l=n(1508);const c="**",h="/",u="[/\\\\]",d="[^/\\\\]",g=/\//g;function f(e,t){switch(e){case 0:return"";case 1:return`${d}*?`;default:return`(?:${u}|${d}+${u}${t?`|${u}${d}+`:""})*?`}}function m(e,t){if(!e)return[];const n=[];let r=!1,i=!1,s="";for(const o of e){switch(o){case t:if(!r&&!i){n.push(s),s="";continue}break;case"{":r=!0;break;case"}":r=!1;break;case"[":i=!0;break;case"]":i=!1}s+=o}return s&&n.push(s),n}function p(e){if(!e)return"";let t="";const n=m(e,h);if(n.every((e=>e===c)))t=".*";else{let e=!1;n.forEach(((r,i)=>{if(r===c){if(e)return;t+=f(2,i===n.length-1)}else{let e=!1,s="",o=!1,a="";for(const n of r)if("}"!==n&&e)s+=n;else if(!o||"]"===n&&a)switch(n){case"{":e=!0;continue;case"[":o=!0;continue;case"}":{const n=`(?:${m(s,",").map((e=>p(e))).join("|")})`;t+=n,e=!1,s="";break}case"]":t+="["+a+"]",o=!1,a="";break;case"?":t+=d;continue;case"*":t+=f(1);continue;default:t+=(0,l.bm)(n)}else{let e;e="-"===n?n:"^"!==n&&"!"!==n||a?n===h?"":(0,l.bm)(n):"^",a+=e}ix(e,t))).filter((e=>e!==S)),e),r=n.length;if(!r)return S;if(1===r)return n[0];const i=function(t,r){for(let i=0,s=n.length;i!!e.allBasenames));s&&(i.allBasenames=s.allBasenames);const o=n.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);o.length&&(i.allPaths=o);return i}(n,t):(i=C.exec(N(n,t)))?T(i[1].substr(1),n,!0):(i=y.exec(N(n,t)))?T(i[1],n,!1):function(e){try{const t=new RegExp(`^${p(e)}$`);return function(n){return t.lastIndex=0,"string"===typeof n&&t.test(n)?e:null}}catch(t){return S}}(n),L.set(r,s)),E(s,e)}function E(e,t){if("string"===typeof t)return e;const n=function(n,r){return(0,i._1)(n,t.base,!a.j9)?e((0,l.NB)(n.substr(t.base.length),o.Vn),r):null};return n.allBasenames=e.allBasenames,n.allPaths=e.allPaths,n.basenames=e.basenames,n.patterns=e.patterns,n}function N(e,t){return t.trimForExclusions&&e.endsWith("/**")?e.substr(0,e.length-2):e}function T(e,t,n){const r=o.Vn===o.SA.sep,i=r?e:e.replace(g,o.Vn),s=o.Vn+i,a=o.SA.sep+e;let l;return l=n?function(n,o){return"string"!==typeof n||n!==i&&!n.endsWith(s)&&(r||n!==e&&!n.endsWith(a))?null:t}:function(n,s){return"string"!==typeof n||n!==i&&(r||n!==e)?null:t},l.allPaths=[(n?"*/":"./")+e],l}function A(e,t,n){return!(!e||"string"!==typeof t)&&I(e)(t,void 0,n)}function I(e,t={}){if(!e)return w;if("string"===typeof e||function(e){const t=e;if(!t)return!1;return"string"===typeof t.base&&"string"===typeof t.pattern}(e)){const n=x(e,t);if(n===S)return w;const r=function(e,t){return!!n(e,t)};return n.allBasenames&&(r.allBasenames=n.allBasenames),n.allPaths&&(r.allPaths=n.allPaths),r}return function(e,t){const n=O(Object.getOwnPropertyNames(e).map((n=>function(e,t,n){if(!1===t)return S;const i=x(e,n);if(i===S)return S;if("boolean"===typeof t)return i;if(t){const n=t.when;if("string"===typeof n){const t=(t,s,o,a)=>{if(!a||!i(t,s))return null;const l=a(n.replace("$(basename)",(()=>o)));return(0,r.Qg)(l)?l.then((t=>t?e:null)):l?e:null};return t.requiresSiblings=!0,t}}return i}(n,e[n],t))).filter((e=>e!==S))),i=n.length;if(!i)return S;if(!n.some((e=>!!e.requiresSiblings))){if(1===i)return n[0];const e=function(e,t){let i;for(let s=0,o=n.length;s{for(const e of i){const t=await e;if("string"===typeof t)return t}return null})():null},t=n.find((e=>!!e.allBasenames));t&&(e.allBasenames=t.allBasenames);const s=n.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);return s.length&&(e.allPaths=s),e}const s=function(e,t,i){let s,a;for(let l=0,c=n.length;l{for(const e of a){const t=await e;if("string"===typeof t)return t}return null})():null},a=n.find((e=>!!e.allBasenames));a&&(s.allBasenames=a.allBasenames);const l=n.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);l.length&&(s.allPaths=l);return s}(e,t)}function O(e,t){const n=e.filter((e=>!!e.basenames));if(n.length<2)return e;const r=n.reduce(((e,t)=>{const n=t.basenames;return n?e.concat(n):e}),[]);let i;if(t){i=[];for(let e=0,n=r.length;e{const n=t.patterns;return n?e.concat(n):e}),[]);const s=function(e,t){if("string"!==typeof e)return null;if(!t){let n;for(n=e.length;n>0;n--){const t=e.charCodeAt(n-1);if(47===t||92===t)break}t=e.substr(n)}const n=r.indexOf(t);return-1!==n?i[n]:null};s.basenames=r,s.patterns=i,s.allBasenames=r;const o=e.filter((e=>!e.basenames));return o.push(s),o}},5600:(e,t,n)=>{"use strict";n.d(t,{e2:()=>o,sN:()=>i,v7:()=>h});var r=n(1508);function i(e,t){switch(typeof e){case"object":return null===e?s(349,t):Array.isArray(e)?(n=e,r=s(104579,r=t),n.reduce(((e,t)=>i(t,e)),r)):function(e,t){return t=s(181387,t),Object.keys(e).sort().reduce(((t,n)=>(t=o(n,t),i(e[n],t))),t)}(e,t);case"string":return o(e,t);case"boolean":return function(e,t){return s(e?433:863,t)}(e,t);case"number":return s(e,t);case"undefined":return s(937,t);default:return s(617,t)}var n,r}function s(e,t){return(t<<5)-t+e|0}function o(e,t){t=s(149417,t);for(let n=0,r=e.length;n>>r)>>>0}function l(e,t=0,n=e.byteLength,r=0){for(let i=0;ie.toString(16).padStart(2,"0"))).join(""):function(e,t,n="0"){for(;e.length>>0).toString(16),t/4)}class h{static{this._bigBlock32=new DataView(new ArrayBuffer(320))}constructor(){this._h0=1732584193,this._h1=4023233417,this._h2=2562383102,this._h3=271733878,this._h4=3285377520,this._buff=new Uint8Array(67),this._buffDV=new DataView(this._buff.buffer),this._buffLen=0,this._totalLen=0,this._leftoverHighSurrogate=0,this._finished=!1}update(e){const t=e.length;if(0===t)return;const n=this._buff;let i,s,o=this._buffLen,a=this._leftoverHighSurrogate;for(0!==a?(i=a,s=-1,a=0):(i=e.charCodeAt(0),s=0);;){let l=i;if(r.pc(i)){if(!(s+1>>6,e[t++]=128|(63&n)>>>0):n<65536?(e[t++]=224|(61440&n)>>>12,e[t++]=128|(4032&n)>>>6,e[t++]=128|(63&n)>>>0):(e[t++]=240|(1835008&n)>>>18,e[t++]=128|(258048&n)>>>12,e[t++]=128|(4032&n)>>>6,e[t++]=128|(63&n)>>>0),t>=64&&(this._step(),t-=64,this._totalLen+=64,e[0]=e[64],e[1]=e[65],e[2]=e[66]),t}digest(){return this._finished||(this._finished=!0,this._leftoverHighSurrogate&&(this._leftoverHighSurrogate=0,this._buffLen=this._push(this._buff,this._buffLen,65533)),this._totalLen+=this._buffLen,this._wrapUp()),c(this._h0)+c(this._h1)+c(this._h2)+c(this._h3)+c(this._h4)}_wrapUp(){this._buff[this._buffLen++]=128,l(this._buff,this._buffLen),this._buffLen>56&&(this._step(),l(this._buff));const e=8*this._totalLen;this._buffDV.setUint32(56,Math.floor(e/4294967296),!1),this._buffDV.setUint32(60,e%4294967296,!1),this._step()}_step(){const e=h._bigBlock32,t=this._buffDV;for(let a=0;a<64;a+=4)e.setUint32(a,t.getUint32(a,!1),!1);for(let h=64;h<320;h+=4)e.setUint32(h,a(e.getUint32(h-12,!1)^e.getUint32(h-32,!1)^e.getUint32(h-56,!1)^e.getUint32(h-64,!1),1),!1);let n,r,i,s=this._h0,o=this._h1,l=this._h2,c=this._h3,u=this._h4;for(let h=0;h<80;h++)h<20?(n=o&l|~o&c,r=1518500249):h<40?(n=o^l^c,r=1859775393):h<60?(n=o&l|o&c|l&c,r=2400959708):(n=o^l^c,r=3395469782),i=a(s,5)+n+u+r+e.getUint32(4*h,!1)&4294967295,u=c,c=l,l=a(o,30),o=s,s=i;this._h0=this._h0+s&4294967295,this._h1=this._h1+o&4294967295,this._h2=this._h2+l&4294967295,this._h3=this._h3+c&4294967295,this._h4=this._h4+u&4294967295}}},2522:(e,t,n)=>{"use strict";var r;n.d(t,{f:()=>r}),function(e){function t(e){return e&&"object"===typeof e&&"function"===typeof e[Symbol.iterator]}e.is=t;const n=Object.freeze([]);function*r(e){yield e}e.empty=function(){return n},e.single=r,e.wrap=function(e){return t(e)?e:r(e)},e.from=function(e){return e||n},e.reverse=function*(e){for(let t=e.length-1;t>=0;t--)yield e[t]},e.isEmpty=function(e){return!e||!0===e[Symbol.iterator]().next().done},e.first=function(e){return e[Symbol.iterator]().next().value},e.some=function(e,t){let n=0;for(const r of e)if(t(r,n++))return!0;return!1},e.find=function(e,t){for(const n of e)if(t(n))return n},e.filter=function*(e,t){for(const n of e)t(n)&&(yield n)},e.map=function*(e,t){let n=0;for(const r of e)yield t(r,n++)},e.flatMap=function*(e,t){let n=0;for(const r of e)yield*t(r,n++)},e.concat=function*(...e){for(const t of e)yield*t},e.reduce=function(e,t,n){let r=n;for(const i of e)r=t(r,i);return r},e.slice=function*(e,t,n=e.length){for(t<0&&(t+=e.length),n<0?n+=e.length:n>e.length&&(n=e.length);ti}]},e.asyncToArray=async function(e){const t=[];for await(const n of e)t.push(n);return Promise.resolve(t)}}(r||(r={}))},1090:(e,t,n)=>{"use strict";n.d(t,{d:()=>r});class r{constructor(e){this.executor=e,this._didRun=!1}get value(){if(!this._didRun)try{this._value=this.executor()}catch(e){this._error=e}finally{this._didRun=!0}if(this._error)throw this._error;return this._value}get rawValue(){return this._value}}},1484:(e,t,n)=>{"use strict";function r(e,t){const n=this;let r,i=!1;return function(){if(i)return r;if(i=!0,t)try{r=e.apply(n,arguments)}finally{t()}else r=e.apply(n,arguments);return r}}n.d(t,{jG:()=>g,$w:()=>m,Cm:()=>d,HE:()=>f,qE:()=>h,AS:()=>c,VD:()=>a,s:()=>u,Ay:()=>o});var i=n(2522);let s=null;function o(e){return s?.trackDisposable(e),e}function a(e){s?.markAsDisposed(e)}function l(e,t){s?.setParent(e,t)}function c(e){if(i.f.is(e)){const n=[];for(const r of e)if(r)try{r.dispose()}catch(t){n.push(t)}if(1===n.length)throw n[0];if(n.length>1)throw new AggregateError(n,"Encountered errors while disposing of store");return Array.isArray(e)?[]:e}if(e)return e.dispose(),e}function h(...e){const t=u((()=>c(e)));return function(e,t){if(s)for(const n of e)s.setParent(n,t)}(e,t),t}function u(e){const t=o({dispose:r((()=>{a(t),e()}))});return t}class d{static{this.DISABLE_DISPOSED_WARNING=!1}constructor(){this._toDispose=new Set,this._isDisposed=!1,o(this)}dispose(){this._isDisposed||(a(this),this._isDisposed=!0,this.clear())}get isDisposed(){return this._isDisposed}clear(){if(0!==this._toDispose.size)try{c(this._toDispose)}finally{this._toDispose.clear()}}add(e){if(!e)return e;if(e===this)throw new Error("Cannot register a disposable on itself!");return l(e,this),this._isDisposed?d.DISABLE_DISPOSED_WARNING||console.warn(new Error("Trying to add a disposable to a DisposableStore that has already been disposed of. The added object will be leaked!").stack):this._toDispose.add(e),e}deleteAndLeak(e){e&&this._toDispose.has(e)&&(this._toDispose.delete(e),l(e,null))}}class g{static{this.None=Object.freeze({dispose(){}})}constructor(){this._store=new d,o(this),l(this._store,this)}dispose(){a(this),this._store.dispose()}_register(e){if(e===this)throw new Error("Cannot register a disposable on itself!");return this._store.add(e)}}class f{constructor(){this._isDisposed=!1,o(this)}get value(){return this._isDisposed?void 0:this._value}set value(e){this._isDisposed||e===this._value||(this._value?.dispose(),e&&l(e,this),this._value=e)}clear(){this.value=void 0}dispose(){this._isDisposed=!0,a(this),this._value?.dispose(),this._value=void 0}}class m{constructor(){this._store=new Map,this._isDisposed=!1,o(this)}dispose(){a(this),this._isDisposed=!0,this.clearAndDisposeAll()}clearAndDisposeAll(){if(this._store.size)try{c(this._store.values())}finally{this._store.clear()}}get(e){return this._store.get(e)}set(e,t,n=!1){this._isDisposed&&console.warn(new Error("Trying to add a disposable to a DisposableMap that has already been disposed of. The added object will be leaked!").stack),n||this._store.get(e)?.dispose(),this._store.set(e,t)}deleteAndDispose(e){this._store.get(e)?.dispose(),this._store.delete(e)}[Symbol.iterator](){return this._store[Symbol.iterator]()}}},8925:(e,t,n)=>{"use strict";n.d(t,{w:()=>i});class r{static{this.Undefined=new r(void 0)}constructor(e){this.element=e,this.next=r.Undefined,this.prev=r.Undefined}}class i{constructor(){this._first=r.Undefined,this._last=r.Undefined,this._size=0}get size(){return this._size}isEmpty(){return this._first===r.Undefined}clear(){let e=this._first;for(;e!==r.Undefined;){const t=e.next;e.prev=r.Undefined,e.next=r.Undefined,e=t}this._first=r.Undefined,this._last=r.Undefined,this._size=0}unshift(e){return this._insert(e,!1)}push(e){return this._insert(e,!0)}_insert(e,t){const n=new r(e);if(this._first===r.Undefined)this._first=n,this._last=n;else if(t){const e=this._last;this._last=n,n.prev=e,e.next=n}else{const e=this._first;this._first=n,n.next=e,e.prev=n}this._size+=1;let i=!1;return()=>{i||(i=!0,this._remove(n))}}shift(){if(this._first!==r.Undefined){const e=this._first.element;return this._remove(this._first),e}}pop(){if(this._last!==r.Undefined){const e=this._last.element;return this._remove(this._last),e}}_remove(e){if(e.prev!==r.Undefined&&e.next!==r.Undefined){const t=e.prev;t.next=e.next,e.next.prev=t}else e.prev===r.Undefined&&e.next===r.Undefined?(this._first=r.Undefined,this._last=r.Undefined):e.next===r.Undefined?(this._last=this._last.prev,this._last.next=r.Undefined):e.prev===r.Undefined&&(this._first=this._first.next,this._first.prev=r.Undefined);this._size-=1}*[Symbol.iterator](){let e=this._first;for(;e!==r.Undefined;)yield e.element,e=e.next}}},4320:(e,t,n)=>{"use strict";var r,i;n.d(t,{cO:()=>h,db:()=>u,fT:()=>o,qK:()=>c});class s{constructor(e,t){this.uri=e,this.value=t}}class o{static{this.defaultToKey=e=>e.toString()}constructor(e,t){if(this[r]="ResourceMap",e instanceof o)this.map=new Map(e.map),this.toKey=t??o.defaultToKey;else if(function(e){return Array.isArray(e)}(e)){this.map=new Map,this.toKey=t??o.defaultToKey;for(const[t,n]of e)this.set(t,n)}else this.map=new Map,this.toKey=e??o.defaultToKey}set(e,t){return this.map.set(this.toKey(e),new s(e,t)),this}get(e){return this.map.get(this.toKey(e))?.value}has(e){return this.map.has(this.toKey(e))}get size(){return this.map.size}clear(){this.map.clear()}delete(e){return this.map.delete(this.toKey(e))}forEach(e,t){"undefined"!==typeof t&&(e=e.bind(t));for(const[n,r]of this.map)e(r.value,r.uri,this)}*values(){for(const e of this.map.values())yield e.value}*keys(){for(const e of this.map.values())yield e.uri}*entries(){for(const e of this.map.values())yield[e.uri,e.value]}*[(r=Symbol.toStringTag,Symbol.iterator)](){for(const[,e]of this.map)yield[e.uri,e.value]}}class a{constructor(){this[i]="LinkedMap",this._map=new Map,this._head=void 0,this._tail=void 0,this._size=0,this._state=0}clear(){this._map.clear(),this._head=void 0,this._tail=void 0,this._size=0,this._state++}isEmpty(){return!this._head&&!this._tail}get size(){return this._size}get first(){return this._head?.value}get last(){return this._tail?.value}has(e){return this._map.has(e)}get(e,t=0){const n=this._map.get(e);if(n)return 0!==t&&this.touch(n,t),n.value}set(e,t,n=0){let r=this._map.get(e);if(r)r.value=t,0!==n&&this.touch(r,n);else{switch(r={key:e,value:t,next:void 0,previous:void 0},n){case 0:case 2:default:this.addItemLast(r);break;case 1:this.addItemFirst(r)}this._map.set(e,r),this._size++}return this}delete(e){return!!this.remove(e)}remove(e){const t=this._map.get(e);if(t)return this._map.delete(e),this.removeItem(t),this._size--,t.value}shift(){if(!this._head&&!this._tail)return;if(!this._head||!this._tail)throw new Error("Invalid list");const e=this._head;return this._map.delete(e.key),this.removeItem(e),this._size--,e.value}forEach(e,t){const n=this._state;let r=this._head;for(;r;){if(t?e.bind(t)(r.value,r.key,this):e(r.value,r.key,this),this._state!==n)throw new Error("LinkedMap got modified during iteration.");r=r.next}}keys(){const e=this,t=this._state;let n=this._head;const r={[Symbol.iterator]:()=>r,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(n){const e={value:n.key,done:!1};return n=n.next,e}return{value:void 0,done:!0}}};return r}values(){const e=this,t=this._state;let n=this._head;const r={[Symbol.iterator]:()=>r,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(n){const e={value:n.value,done:!1};return n=n.next,e}return{value:void 0,done:!0}}};return r}entries(){const e=this,t=this._state;let n=this._head;const r={[Symbol.iterator]:()=>r,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(n){const e={value:[n.key,n.value],done:!1};return n=n.next,e}return{value:void 0,done:!0}}};return r}[(i=Symbol.toStringTag,Symbol.iterator)](){return this.entries()}trimOld(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._head,n=this.size;for(;t&&n>e;)this._map.delete(t.key),t=t.next,n--;this._head=t,this._size=n,t&&(t.previous=void 0),this._state++}trimNew(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._tail,n=this.size;for(;t&&n>e;)this._map.delete(t.key),t=t.previous,n--;this._tail=t,this._size=n,t&&(t.next=void 0),this._state++}addItemFirst(e){if(this._head||this._tail){if(!this._head)throw new Error("Invalid list");e.next=this._head,this._head.previous=e}else this._tail=e;this._head=e,this._state++}addItemLast(e){if(this._head||this._tail){if(!this._tail)throw new Error("Invalid list");e.previous=this._tail,this._tail.next=e}else this._head=e;this._tail=e,this._state++}removeItem(e){if(e===this._head&&e===this._tail)this._head=void 0,this._tail=void 0;else if(e===this._head){if(!e.next)throw new Error("Invalid list");e.next.previous=void 0,this._head=e.next}else if(e===this._tail){if(!e.previous)throw new Error("Invalid list");e.previous.next=void 0,this._tail=e.previous}else{const t=e.next,n=e.previous;if(!t||!n)throw new Error("Invalid list");t.previous=n,n.next=t}e.next=void 0,e.previous=void 0,this._state++}touch(e,t){if(!this._head||!this._tail)throw new Error("Invalid list");if(1===t||2===t)if(1===t){if(e===this._head)return;const t=e.next,n=e.previous;e===this._tail?(n.next=void 0,this._tail=n):(t.previous=n,n.next=t),e.previous=void 0,e.next=this._head,this._head.previous=e,this._head=e,this._state++}else if(2===t){if(e===this._tail)return;const t=e.next,n=e.previous;e===this._head?(t.previous=void 0,this._head=t):(t.previous=n,n.next=t),e.next=void 0,e.previous=this._tail,this._tail.next=e,this._tail=e,this._state++}}toJSON(){const e=[];return this.forEach(((t,n)=>{e.push([n,t])})),e}fromJSON(e){this.clear();for(const[t,n]of e)this.set(t,n)}}class l extends a{constructor(e,t=1){super(),this._limit=e,this._ratio=Math.min(Math.max(0,t),1)}get limit(){return this._limit}set limit(e){this._limit=e,this.checkTrim()}get(e,t=2){return super.get(e,t)}peek(e){return super.get(e,0)}set(e,t){return super.set(e,t,2),this}checkTrim(){this.size>this._limit&&this.trim(Math.round(this._limit*this._ratio))}}class c extends l{constructor(e,t=1){super(e,t)}trim(e){this.trimOld(e)}set(e,t){return super.set(e,t),this.checkTrim(),this}}class h{constructor(e){if(this._m1=new Map,this._m2=new Map,e)for(const[t,n]of e)this.set(t,n)}clear(){this._m1.clear(),this._m2.clear()}set(e,t){this._m1.set(e,t),this._m2.set(t,e)}get(e){return this._m1.get(e)}getKey(e){return this._m2.get(e)}delete(e){const t=this._m1.get(e);return void 0!==t&&(this._m1.delete(e),this._m2.delete(t),!0)}keys(){return this._m1.keys()}values(){return this._m1.values()}}class u{constructor(){this.map=new Map}add(e,t){let n=this.map.get(e);n||(n=new Set,this.map.set(e,n)),n.add(t)}delete(e,t){const n=this.map.get(e);n&&(n.delete(t),0===n.size&&this.map.delete(e))}forEach(e,t){const n=this.map.get(e);n&&n.forEach(t)}get(e){const t=this.map.get(e);return t||new Set}}},1939:(e,t,n)=>{"use strict";n.d(t,{K:()=>r});const r=Object.freeze({text:"text/plain",binary:"application/octet-stream",unknown:"application/unknown",markdown:"text/markdown",latex:"text/latex",uriList:"text/uri-list"})},6456:(e,t,n)=>{"use strict";n.d(t,{ny:()=>r,v$:()=>c,zl:()=>d});var r,i=n(4383),s=n(8067),o=n(1508),a=n(9400),l=n(8821);function c(e,t){return a.r.isUri(e)?(0,o.Q_)(e.scheme,t):(0,o.ns)(e,t+":")}!function(e){e.inMemory="inmemory",e.vscode="vscode",e.internal="private",e.walkThrough="walkThrough",e.walkThroughSnippet="walkThroughSnippet",e.http="http",e.https="https",e.file="file",e.mailto="mailto",e.untitled="untitled",e.data="data",e.command="command",e.vscodeRemote="vscode-remote",e.vscodeRemoteResource="vscode-remote-resource",e.vscodeManagedRemoteResource="vscode-managed-remote-resource",e.vscodeUserData="vscode-userdata",e.vscodeCustomEditor="vscode-custom-editor",e.vscodeNotebookCell="vscode-notebook-cell",e.vscodeNotebookCellMetadata="vscode-notebook-cell-metadata",e.vscodeNotebookCellMetadataDiff="vscode-notebook-cell-metadata-diff",e.vscodeNotebookCellOutput="vscode-notebook-cell-output",e.vscodeNotebookCellOutputDiff="vscode-notebook-cell-output-diff",e.vscodeNotebookMetadata="vscode-notebook-metadata",e.vscodeInteractiveInput="vscode-interactive-input",e.vscodeSettings="vscode-settings",e.vscodeWorkspaceTrust="vscode-workspace-trust",e.vscodeTerminal="vscode-terminal",e.vscodeChatCodeBlock="vscode-chat-code-block",e.vscodeChatCodeCompareBlock="vscode-chat-code-compare-block",e.vscodeChatSesssion="vscode-chat-editor",e.webviewPanel="webview-panel",e.vscodeWebview="vscode-webview",e.extension="extension",e.vscodeFileResource="vscode-file",e.tmp="tmp",e.vsls="vsls",e.vscodeSourceControl="vscode-scm",e.commentsInput="comment",e.codeSetting="code-setting",e.outputChannel="output"}(r||(r={}));const h=new class{constructor(){this._hosts=Object.create(null),this._ports=Object.create(null),this._connectionTokens=Object.create(null),this._preferredWebSchema="http",this._delegate=null,this._serverRootPath="/"}setPreferredWebSchema(e){this._preferredWebSchema=e}get _remoteResourcesPath(){return l.SA.join(this._serverRootPath,r.vscodeRemoteResource)}rewrite(e){if(this._delegate)try{return this._delegate(e)}catch(h){return i.dz(h),e}const t=e.authority;let n=this._hosts[t];n&&-1!==n.indexOf(":")&&-1===n.indexOf("[")&&(n=`[${n}]`);const o=this._ports[t],l=this._connectionTokens[t];let c=`path=${encodeURIComponent(e.path)}`;return"string"===typeof l&&(c+=`&tkn=${encodeURIComponent(l)}`),a.r.from({scheme:s.HZ?this._preferredWebSchema:r.vscodeRemoteResource,authority:`${n}:${o}`,path:this._remoteResourcesPath,query:c})}};class u{static{this.FALLBACK_AUTHORITY="vscode-app"}asBrowserUri(e){const t=this.toUri(e);return this.uriToBrowserUri(t)}uriToBrowserUri(e){return e.scheme===r.vscodeRemote?h.rewrite(e):e.scheme!==r.file||!s.ib&&s.lg!==`${r.vscodeFileResource}://${u.FALLBACK_AUTHORITY}`?e:e.with({scheme:r.vscodeFileResource,authority:e.authority||u.FALLBACK_AUTHORITY,query:null,fragment:null})}toUri(e,t){if(a.r.isUri(e))return e;if(globalThis._VSCODE_FILE_ROOT){const t=globalThis._VSCODE_FILE_ROOT;if(/^\w[\w\d+.-]*:\/\//.test(t))return a.r.joinPath(a.r.parse(t,!0),e);const n=l.fj(t,e);return a.r.file(n)}return a.r.parse(t.toUrl(e))}}const d=new u;var g;!function(e){const t=new Map([["1",{"Cross-Origin-Opener-Policy":"same-origin"}],["2",{"Cross-Origin-Embedder-Policy":"require-corp"}],["3",{"Cross-Origin-Opener-Policy":"same-origin","Cross-Origin-Embedder-Policy":"require-corp"}]]);e.CoopAndCoep=Object.freeze(t.get("3"));const n="vscode-coi";e.getHeadersFromQuery=function(e){let r;"string"===typeof e?r=new URL(e).searchParams:e instanceof URL?r=e.searchParams:a.r.isUri(e)&&(r=new URL(e.toString(!0)).searchParams);const i=r?.get(n);if(i)return t.get(i)},e.addSearchParam=function(e,t,r){if(!globalThis.crossOriginIsolated)return;const i=t&&r?"3":r?"2":"1";e instanceof URLSearchParams?e.set(n,i):e[n]=i}}(g||(g={}))},146:(e,t,n)=>{"use strict";n.d(t,{V0:()=>i,aI:()=>r,kT:()=>s});Object.prototype.hasOwnProperty;function r(e,t){if(e===t)return!0;if(null===e||void 0===e||null===t||void 0===t)return!1;if(typeof e!==typeof t)return!1;if("object"!==typeof e)return!1;if(Array.isArray(e)!==Array.isArray(t))return!1;let n,i;if(Array.isArray(e)){if(e.length!==t.length)return!1;for(n=0;nfunction(){const n=Array.prototype.slice.call(arguments,0);return t(e,n)},r={};for(const i of e)r[i]=n(i);return r}},8821:(e,t,n)=>{"use strict";n.d(t,{P8:()=>N,pD:()=>E,LC:()=>T,fj:()=>w,S8:()=>L,SA:()=>y,V8:()=>x,hd:()=>S,Vn:()=>A,IN:()=>v});var r=n(8067);let i;const s=globalThis.vscode;if("undefined"!==typeof s&&"undefined"!==typeof s.process){const e=s.process;i={get platform(){return e.platform},get arch(){return e.arch},get env(){return e.env},cwd:()=>e.cwd()}}else i="undefined"!==typeof process&&"string"===typeof process?.versions?.node?{get platform(){return process.platform},get arch(){return process.arch},get env(){return{NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}},cwd:()=>({NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}.VSCODE_CWD||process.cwd())}:{get platform(){return r.uF?"win32":r.zx?"darwin":"linux"},get arch(){},get env(){return{}},cwd:()=>"/"};const o=i.cwd,a=(i.env,i.platform),l=46,c=47,h=92,u=58;class d extends Error{constructor(e,t,n){let r;"string"===typeof t&&0===t.indexOf("not ")?(r="must not be",t=t.replace(/^not /,"")):r="must be";const i=-1!==e.indexOf(".")?"property":"argument";let s=`The "${e}" ${i} ${r} of type ${t}`;s+=". Received type "+typeof n,super(s),this.code="ERR_INVALID_ARG_TYPE"}}function g(e,t){if("string"!==typeof e)throw new d(t,"string",e)}const f="win32"===a;function m(e){return e===c||e===h}function p(e){return e===c}function b(e){return e>=65&&e<=90||e>=97&&e<=122}function _(e,t,n,r){let i="",s=0,o=-1,a=0,h=0;for(let u=0;u<=e.length;++u){if(u2){const e=i.lastIndexOf(n);-1===e?(i="",s=0):(i=i.slice(0,e),s=i.length-1-i.lastIndexOf(n)),o=u,a=0;continue}if(0!==i.length){i="",s=0,o=u,a=0;continue}}t&&(i+=i.length>0?`${n}..`:"..",s=2)}else i.length>0?i+=`${n}${e.slice(o+1,u)}`:i=e.slice(o+1,u),s=u-o-1;o=u,a=0}else h===l&&-1!==a?++a:a=-1}return i}function k(e,t){!function(e,t){if(null===e||"object"!==typeof e)throw new d(t,"Object",e)}(t,"pathObject");const n=t.dir||t.root,r=t.base||`${t.name||""}${i=t.ext,i?`${"."===i[0]?"":"."}${i}`:""}`;var i;return n?n===t.root?`${n}${r}`:`${n}${e}${r}`:r}const v={resolve(...e){let t="",n="",r=!1;for(let i=e.length-1;i>=-1;i--){let s;if(i>=0){if(s=e[i],g(s,`paths[${i}]`),0===s.length)continue}else 0===t.length?s=o():(s={NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}[`=${t}`]||o(),(void 0===s||s.slice(0,2).toLowerCase()!==t.toLowerCase()&&s.charCodeAt(2)===h)&&(s=`${t}\\`));const a=s.length;let l=0,c="",d=!1;const f=s.charCodeAt(0);if(1===a)m(f)&&(l=1,d=!0);else if(m(f))if(d=!0,m(s.charCodeAt(1))){let e=2,t=e;for(;e2&&m(s.charCodeAt(2))&&(d=!0,l=3));if(c.length>0)if(t.length>0){if(c.toLowerCase()!==t.toLowerCase())continue}else t=c;if(r){if(t.length>0)break}else if(n=`${s.slice(l)}\\${n}`,r=d,d&&t.length>0)break}return n=_(n,!r,"\\",m),r?`${t}\\${n}`:`${t}${n}`||"."},normalize(e){g(e,"path");const t=e.length;if(0===t)return".";let n,r=0,i=!1;const s=e.charCodeAt(0);if(1===t)return p(s)?"\\":e;if(m(s))if(i=!0,m(e.charCodeAt(1))){let i=2,s=i;for(;i2&&m(e.charCodeAt(2))&&(i=!0,r=3));let o=r0&&m(e.charCodeAt(t-1))&&(o+="\\"),void 0===n?i?`\\${o}`:o:i?`${n}\\${o}`:`${n}${o}`},isAbsolute(e){g(e,"path");const t=e.length;if(0===t)return!1;const n=e.charCodeAt(0);return m(n)||t>2&&b(n)&&e.charCodeAt(1)===u&&m(e.charCodeAt(2))},join(...e){if(0===e.length)return".";let t,n;for(let s=0;s0&&(void 0===t?t=n=r:t+=`\\${r}`)}if(void 0===t)return".";let r=!0,i=0;if("string"===typeof n&&m(n.charCodeAt(0))){++i;const e=n.length;e>1&&m(n.charCodeAt(1))&&(++i,e>2&&(m(n.charCodeAt(2))?++i:r=!1))}if(r){for(;i=2&&(t=`\\${t.slice(i)}`)}return v.normalize(t)},relative(e,t){if(g(e,"from"),g(t,"to"),e===t)return"";const n=v.resolve(e),r=v.resolve(t);if(n===r)return"";if((e=n.toLowerCase())===(t=r.toLowerCase()))return"";let i=0;for(;ii&&e.charCodeAt(s-1)===h;)s--;const o=s-i;let a=0;for(;aa&&t.charCodeAt(l-1)===h;)l--;const c=l-a,u=ou){if(t.charCodeAt(a+f)===h)return r.slice(a+f+1);if(2===f)return r.slice(a+f)}o>u&&(e.charCodeAt(i+f)===h?d=f:2===f&&(d=3)),-1===d&&(d=0)}let m="";for(f=i+d+1;f<=s;++f)f!==s&&e.charCodeAt(f)!==h||(m+=0===m.length?"..":"\\..");return a+=d,m.length>0?`${m}${r.slice(a,l)}`:(r.charCodeAt(a)===h&&++a,r.slice(a,l))},toNamespacedPath(e){if("string"!==typeof e||0===e.length)return e;const t=v.resolve(e);if(t.length<=2)return e;if(t.charCodeAt(0)===h){if(t.charCodeAt(1)===h){const e=t.charCodeAt(2);if(63!==e&&e!==l)return`\\\\?\\UNC\\${t.slice(2)}`}}else if(b(t.charCodeAt(0))&&t.charCodeAt(1)===u&&t.charCodeAt(2)===h)return`\\\\?\\${t}`;return e},dirname(e){g(e,"path");const t=e.length;if(0===t)return".";let n=-1,r=0;const i=e.charCodeAt(0);if(1===t)return m(i)?e:".";if(m(i)){if(n=r=1,m(e.charCodeAt(1))){let i=2,s=i;for(;i2&&m(e.charCodeAt(2))?3:2,r=n);let s=-1,o=!0;for(let a=t-1;a>=r;--a)if(m(e.charCodeAt(a))){if(!o){s=a;break}}else o=!1;if(-1===s){if(-1===n)return".";s=n}return e.slice(0,s)},basename(e,t){void 0!==t&&g(t,"suffix"),g(e,"path");let n,r=0,i=-1,s=!0;if(e.length>=2&&b(e.charCodeAt(0))&&e.charCodeAt(1)===u&&(r=2),void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let o=t.length-1,a=-1;for(n=e.length-1;n>=r;--n){const l=e.charCodeAt(n);if(m(l)){if(!s){r=n+1;break}}else-1===a&&(s=!1,a=n+1),o>=0&&(l===t.charCodeAt(o)?-1===--o&&(i=n):(o=-1,i=a))}return r===i?i=a:-1===i&&(i=e.length),e.slice(r,i)}for(n=e.length-1;n>=r;--n)if(m(e.charCodeAt(n))){if(!s){r=n+1;break}}else-1===i&&(s=!1,i=n+1);return-1===i?"":e.slice(r,i)},extname(e){g(e,"path");let t=0,n=-1,r=0,i=-1,s=!0,o=0;e.length>=2&&e.charCodeAt(1)===u&&b(e.charCodeAt(0))&&(t=r=2);for(let a=e.length-1;a>=t;--a){const t=e.charCodeAt(a);if(m(t)){if(!s){r=a+1;break}}else-1===i&&(s=!1,i=a+1),t===l?-1===n?n=a:1!==o&&(o=1):-1!==n&&(o=-1)}return-1===n||-1===i||0===o||1===o&&n===i-1&&n===r+1?"":e.slice(n,i)},format:k.bind(null,"\\"),parse(e){g(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const n=e.length;let r=0,i=e.charCodeAt(0);if(1===n)return m(i)?(t.root=t.dir=e,t):(t.base=t.name=e,t);if(m(i)){if(r=1,m(e.charCodeAt(1))){let t=2,i=t;for(;t0&&(t.root=e.slice(0,r));let s=-1,o=r,a=-1,c=!0,h=e.length-1,d=0;for(;h>=r;--h)if(i=e.charCodeAt(h),m(i)){if(!c){o=h+1;break}}else-1===a&&(c=!1,a=h+1),i===l?-1===s?s=h:1!==d&&(d=1):-1!==s&&(d=-1);return-1!==a&&(-1===s||0===d||1===d&&s===a-1&&s===o+1?t.base=t.name=e.slice(o,a):(t.name=e.slice(o,s),t.base=e.slice(o,a),t.ext=e.slice(s,a))),t.dir=o>0&&o!==r?e.slice(0,o-1):t.root,t},sep:"\\",delimiter:";",win32:null,posix:null},C=(()=>{if(f){const e=/\\/g;return()=>{const t=o().replace(e,"/");return t.slice(t.indexOf("/"))}}return()=>o()})(),y={resolve(...e){let t="",n=!1;for(let r=e.length-1;r>=-1&&!n;r--){const i=r>=0?e[r]:C();g(i,`paths[${r}]`),0!==i.length&&(t=`${i}/${t}`,n=i.charCodeAt(0)===c)}return t=_(t,!n,"/",p),n?`/${t}`:t.length>0?t:"."},normalize(e){if(g(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===c,n=e.charCodeAt(e.length-1)===c;return 0===(e=_(e,!t,"/",p)).length?t?"/":n?"./":".":(n&&(e+="/"),t?`/${e}`:e)},isAbsolute:e=>(g(e,"path"),e.length>0&&e.charCodeAt(0)===c),join(...e){if(0===e.length)return".";let t;for(let n=0;n0&&(void 0===t?t=r:t+=`/${r}`)}return void 0===t?".":y.normalize(t)},relative(e,t){if(g(e,"from"),g(t,"to"),e===t)return"";if((e=y.resolve(e))===(t=y.resolve(t)))return"";const n=e.length,r=n-1,i=t.length-1,s=rs){if(t.charCodeAt(1+a)===c)return t.slice(1+a+1);if(0===a)return t.slice(1+a)}else r>s&&(e.charCodeAt(1+a)===c?o=a:0===a&&(o=0));let l="";for(a=1+o+1;a<=n;++a)a!==n&&e.charCodeAt(a)!==c||(l+=0===l.length?"..":"/..");return`${l}${t.slice(1+o)}`},toNamespacedPath:e=>e,dirname(e){if(g(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===c;let n=-1,r=!0;for(let i=e.length-1;i>=1;--i)if(e.charCodeAt(i)===c){if(!r){n=i;break}}else r=!1;return-1===n?t?"/":".":t&&1===n?"//":e.slice(0,n)},basename(e,t){void 0!==t&&g(t,"ext"),g(e,"path");let n,r=0,i=-1,s=!0;if(void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let o=t.length-1,a=-1;for(n=e.length-1;n>=0;--n){const l=e.charCodeAt(n);if(l===c){if(!s){r=n+1;break}}else-1===a&&(s=!1,a=n+1),o>=0&&(l===t.charCodeAt(o)?-1===--o&&(i=n):(o=-1,i=a))}return r===i?i=a:-1===i&&(i=e.length),e.slice(r,i)}for(n=e.length-1;n>=0;--n)if(e.charCodeAt(n)===c){if(!s){r=n+1;break}}else-1===i&&(s=!1,i=n+1);return-1===i?"":e.slice(r,i)},extname(e){g(e,"path");let t=-1,n=0,r=-1,i=!0,s=0;for(let o=e.length-1;o>=0;--o){const a=e.charCodeAt(o);if(a!==c)-1===r&&(i=!1,r=o+1),a===l?-1===t?t=o:1!==s&&(s=1):-1!==t&&(s=-1);else if(!i){n=o+1;break}}return-1===t||-1===r||0===s||1===s&&t===r-1&&t===n+1?"":e.slice(t,r)},format:k.bind(null,"/"),parse(e){g(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const n=e.charCodeAt(0)===c;let r;n?(t.root="/",r=1):r=0;let i=-1,s=0,o=-1,a=!0,h=e.length-1,u=0;for(;h>=r;--h){const t=e.charCodeAt(h);if(t!==c)-1===o&&(a=!1,o=h+1),t===l?-1===i?i=h:1!==u&&(u=1):-1!==i&&(u=-1);else if(!a){s=h+1;break}}if(-1!==o){const r=0===s&&n?1:s;-1===i||0===u||1===u&&i===o-1&&i===s+1?t.base=t.name=e.slice(r,o):(t.name=e.slice(r,i),t.base=e.slice(r,o),t.ext=e.slice(i,o))}return s>0?t.dir=e.slice(0,s-1):n&&(t.dir="/"),t},sep:"/",delimiter:":",win32:null,posix:null};y.win32=v.win32=v,y.posix=v.posix=y;const L=f?v.normalize:y.normalize,w=f?v.join:y.join,S=f?v.resolve:y.resolve,x=f?v.relative:y.relative,E=f?v.dirname:y.dirname,N=f?v.basename:y.basename,T=f?v.extname:y.extname,A=f?v.sep:y.sep},8067:(e,t,n)=>{"use strict";n.d(t,{H8:()=>P,HZ:()=>T,OS:()=>R,UP:()=>j,_p:()=>M,cm:()=>F,gm:()=>V,ib:()=>N,j9:()=>E,lg:()=>A,nr:()=>z,uF:()=>S,zx:()=>x});var r=n(8209);const i="en";let s,o,a=!1,l=!1,c=!1,h=!1,u=!1,d=!1,g=!1,f=!1,m=!1,p=!1,b=null,_=null,k=null;const v=globalThis;let C;"undefined"!==typeof v.vscode&&"undefined"!==typeof v.vscode.process?C=v.vscode.process:"undefined"!==typeof process&&"string"===typeof process?.versions?.node&&(C=process);const y="string"===typeof C?.versions?.electron,L=y&&"renderer"===C?.type;if("object"===typeof C){a="win32"===C.platform,l="darwin"===C.platform,c="linux"===C.platform,h=c&&!!C.env.SNAP&&!!C.env.SNAP_REVISION,g=y,m=!!C.env.CI||!!C.env.BUILD_ARTIFACTSTAGINGDIRECTORY,s=i,b=i;const e=C.env.VSCODE_NLS_CONFIG;if(e)try{const t=JSON.parse(e);s=t.userLocale,_=t.osLocale,b=t.resolvedLanguage||i,k=t.languagePack?.translationsConfigFile}catch(q){}u=!0}else"object"!==typeof navigator||L?console.error("Unable to resolve platform."):(o=navigator.userAgent,a=o.indexOf("Windows")>=0,l=o.indexOf("Macintosh")>=0,f=(o.indexOf("Macintosh")>=0||o.indexOf("iPad")>=0||o.indexOf("iPhone")>=0)&&!!navigator.maxTouchPoints&&navigator.maxTouchPoints>0,c=o.indexOf("Linux")>=0,p=o?.indexOf("Mobi")>=0,d=!0,b=r.i8()||i,s=navigator.language.toLowerCase(),_=s);let w=0;l?w=1:a?w=3:c&&(w=2);const S=a,x=l,E=c,N=u,T=d,A=d&&"function"===typeof v.importScripts?v.origin:void 0,I=o,O="function"===typeof v.postMessage&&!v.importScripts,M=(()=>{if(O){const e=[];v.addEventListener("message",(t=>{if(t.data&&t.data.vscodeScheduleAsyncWork)for(let n=0,r=e.length;n{const r=++t;e.push({id:r,callback:n}),v.postMessage({vscodeScheduleAsyncWork:r},"*")}}return e=>setTimeout(e)})(),R=l||f?2:a?1:3;let D=!0,B=!1;function F(){if(!B){B=!0;const e=new Uint8Array(2);e[0]=1,e[1]=2;const t=new Uint16Array(e.buffer);D=513===t[0]}return D}const P=!!(I&&I.indexOf("Chrome")>=0),V=!!(I&&I.indexOf("Firefox")>=0),z=!!(!P&&I&&I.indexOf("Safari")>=0),j=!!(I&&I.indexOf("Edg/")>=0);I&&I.indexOf("Android")},9403:(e,t,n)=>{"use strict";n.d(t,{B6:()=>m,P8:()=>d});var r=n(9326),i=n(6456),s=n(8821),o=n(8067),a=n(1508),l=n(9400);function c(e){return(0,l.I)(e,!0)}class h{constructor(e){this._ignorePathCasing=e}compare(e,t,n=!1){return e===t?0:(0,a.UD)(this.getComparisonKey(e,n),this.getComparisonKey(t,n))}isEqual(e,t,n=!1){return e===t||!(!e||!t)&&this.getComparisonKey(e,n)===this.getComparisonKey(t,n)}getComparisonKey(e,t=!1){return e.with({path:this._ignorePathCasing(e)?e.path.toLowerCase():void 0,fragment:t?null:void 0}).toString()}isEqualOrParent(e,t,n=!1){if(e.scheme===t.scheme){if(e.scheme===i.ny.file)return r._1(c(e),c(t),this._ignorePathCasing(e))&&e.query===t.query&&(n||e.fragment===t.fragment);if(g(e.authority,t.authority))return r._1(e.path,t.path,this._ignorePathCasing(e),"/")&&e.query===t.query&&(n||e.fragment===t.fragment)}return!1}joinPath(e,...t){return l.r.joinPath(e,...t)}basenameOrAuthority(e){return d(e)||e.authority}basename(e){return s.SA.basename(e.path)}extname(e){return s.SA.extname(e.path)}dirname(e){if(0===e.path.length)return e;let t;return e.scheme===i.ny.file?t=l.r.file(s.pD(c(e))).path:(t=s.SA.dirname(e.path),e.authority&&t.length&&47!==t.charCodeAt(0)&&(console.error(`dirname("${e.toString})) resulted in a relative path`),t="/")),e.with({path:t})}normalizePath(e){if(!e.path.length)return e;let t;return t=e.scheme===i.ny.file?l.r.file(s.S8(c(e))).path:s.SA.normalize(e.path),e.with({path:t})}relativePath(e,t){if(e.scheme!==t.scheme||!g(e.authority,t.authority))return;if(e.scheme===i.ny.file){const n=s.V8(c(e),c(t));return o.uF?r.TH(n):n}let n=e.path||"/";const a=t.path||"/";if(this._ignorePathCasing(e)){let e=0;for(const t=Math.min(n.length,a.length);er.Zn(n).length&&n[n.length-1]===t}{const t=e.path;return t.length>1&&47===t.charCodeAt(t.length-1)&&!/^[a-zA-Z]:(\/$|\\$)/.test(e.fsPath)}}removeTrailingPathSeparator(e,t=s.Vn){return f(e,t)?e.with({path:e.path.substr(0,e.path.length-1)}):e}addTrailingPathSeparator(e,t=s.Vn){let n=!1;if(e.scheme===i.ny.file){const i=c(e);n=void 0!==i&&i.length===r.Zn(i).length&&i[i.length-1]===t}else{t="/";const r=e.path;n=1===r.length&&47===r.charCodeAt(r.length-1)}return n||f(e,t)?e:e.with({path:e.path+"/"})}}const u=new h((()=>!1)),d=(new h((e=>e.scheme!==i.ny.file||!o.j9)),new h((e=>!0)),u.isEqual.bind(u),u.isEqualOrParent.bind(u),u.getComparisonKey.bind(u),u.basenameOrAuthority.bind(u),u.basename.bind(u)),g=(u.extname.bind(u),u.dirname.bind(u),u.joinPath.bind(u),u.normalizePath.bind(u),u.relativePath.bind(u),u.resolvePath.bind(u),u.isAbsolutePath.bind(u),u.isEqualAuthority.bind(u)),f=u.hasTrailingPathSeparator.bind(u);u.removeTrailingPathSeparator.bind(u),u.addTrailingPathSeparator.bind(u);var m;!function(e){e.META_DATA_LABEL="label",e.META_DATA_DESCRIPTION="description",e.META_DATA_SIZE="size",e.META_DATA_MIME="mime",e.parseMetaData=function(t){const n=new Map;t.path.substring(t.path.indexOf(";")+1,t.path.lastIndexOf(";")).split(";").forEach((e=>{const[t,r]=e.split(":");t&&r&&n.set(t,r)}));const r=t.path.substring(0,t.path.indexOf(";"));return r&&n.set(e.META_DATA_MIME,r),n}}(m||(m={}))},8381:(e,t,n)=>{"use strict";n.d(t,{W:()=>i});const r=globalThis.performance&&"function"===typeof globalThis.performance.now;class i{static create(e){return new i(e)}constructor(e){this._now=r&&!1===e?Date.now:globalThis.performance.now.bind(globalThis.performance),this._startTime=this._now(),this._stopTime=-1}stop(){this._stopTime=this._now()}reset(){this._startTime=this._now(),this._stopTime=-1}elapsed(){return-1!==this._stopTime?this._stopTime-this._startTime:this._now()-this._startTime}}},1508:(e,t,n)=>{"use strict";n.d(t,{$X:()=>O,AV:()=>s,E_:()=>N,HG:()=>d,LJ:()=>y,LU:()=>B,NB:()=>l,OS:()=>c,Q_:()=>k,Ss:()=>R,UD:()=>f,Wv:()=>_,Z5:()=>w,_J:()=>I,aC:()=>A,bm:()=>a,eY:()=>h,jy:()=>o,km:()=>x,lT:()=>g,ne:()=>M,ns:()=>v,pc:()=>C,r_:()=>D,tk:()=>F,tl:()=>z,uz:()=>u,y_:()=>j,z_:()=>L});var r=n(1788),i=n(1090);function s(e){return!e||"string"!==typeof e||0===e.trim().length}function o(e){return e.replace(/[<>"'&]/g,(e=>{switch(e){case"<":return"<";case">":return">";case'"':return""";case"'":return"'";case"&":return"&"}return e}))}function a(e){return e.replace(/[\\\{\}\*\+\?\|\^\$\.\[\]\(\)]/g,"\\$&")}function l(e,t){if(!e||!t)return e;const n=t.length;if(0===n||0===e.length)return e;let r=0;for(;e.indexOf(t,r)===r;)r+=n;return e.substring(r)}function c(e,t,n={}){if(!e)throw new Error("Cannot create regex from empty string");t||(e=a(e)),n.wholeWord&&(/\B/.test(e.charAt(0))||(e="\\b"+e),/\B/.test(e.charAt(e.length-1))||(e+="\\b"));let r="";return n.global&&(r+="g"),n.matchCase||(r+="i"),n.multiline&&(r+="m"),n.unicode&&(r+="u"),new RegExp(e,r)}function h(e){if("^"===e.source||"^$"===e.source||"$"===e.source||"^\\s*$"===e.source)return!1;return!(!e.exec("")||0!==e.lastIndex)}function u(e){return e.split(/\r\n|\r|\n/)}function d(e){for(let t=0,n=e.length;t=0;n--){const t=e.charCodeAt(n);if(32!==t&&9!==t)return n}return-1}function f(e,t){return et?1:0}function m(e,t,n=0,r=e.length,i=0,s=t.length){for(;ns)return 1}const o=r-n,a=s-i;return oa?1:0}function p(e,t,n=0,r=e.length,i=0,s=t.length){for(;n=128||a>=128)return m(e.toLowerCase(),t.toLowerCase(),n,r,i,s);b(o)&&(o-=32),b(a)&&(a-=32);const l=o-a;if(0!==l)return l}const o=r-n,a=s-i;return oa?1:0}function b(e){return e>=97&&e<=122}function _(e){return e>=65&&e<=90}function k(e,t){return e.length===t.length&&0===p(e,t)}function v(e,t){const n=t.length;return!(t.length>e.length)&&0===p(e,t,0,n)}function C(e){return 55296<=e&&e<=56319}function y(e){return 56320<=e&&e<=57343}function L(e,t){return t-56320+(e-55296<<10)+65536}function w(e,t,n){const r=e.charCodeAt(n);if(C(r)&&n+11){const r=e.charCodeAt(t-2);if(C(r))return L(r,n)}return n}(this._str,this._offset);return this._offset-=e>=65536?2:1,e}nextCodePoint(){const e=w(this._str,this._len,this._offset);return this._offset+=e>=65536?2:1,e}eol(){return this._offset>=this._len}}class x{get offset(){return this._iterator.offset}constructor(e,t=0){this._iterator=new S(e,t)}nextGraphemeLength(){const e=V.getInstance(),t=this._iterator,n=t.offset;let r=e.getGraphemeBreakType(t.nextCodePoint());for(;!t.eol();){const n=t.offset,i=e.getGraphemeBreakType(t.nextCodePoint());if(P(r,i)){t.setOffset(n);break}r=i}return t.offset-n}prevGraphemeLength(){const e=V.getInstance(),t=this._iterator,n=t.offset;let r=e.getGraphemeBreakType(t.prevCodePoint());for(;t.offset>0;){const n=t.offset,i=e.getGraphemeBreakType(t.prevCodePoint());if(P(i,r)){t.setOffset(n);break}r=i}return n-t.offset}eol(){return this._iterator.eol()}}let E;function N(e){return E||(E=/(?:[\u05BE\u05C0\u05C3\u05C6\u05D0-\u05F4\u0608\u060B\u060D\u061B-\u064A\u066D-\u066F\u0671-\u06D5\u06E5\u06E6\u06EE\u06EF\u06FA-\u0710\u0712-\u072F\u074D-\u07A5\u07B1-\u07EA\u07F4\u07F5\u07FA\u07FE-\u0815\u081A\u0824\u0828\u0830-\u0858\u085E-\u088E\u08A0-\u08C9\u200F\uFB1D\uFB1F-\uFB28\uFB2A-\uFD3D\uFD50-\uFDC7\uFDF0-\uFDFC\uFE70-\uFEFC]|\uD802[\uDC00-\uDD1B\uDD20-\uDE00\uDE10-\uDE35\uDE40-\uDEE4\uDEEB-\uDF35\uDF40-\uDFFF]|\uD803[\uDC00-\uDD23\uDE80-\uDEA9\uDEAD-\uDF45\uDF51-\uDF81\uDF86-\uDFF6]|\uD83A[\uDC00-\uDCCF\uDD00-\uDD43\uDD4B-\uDFFF]|\uD83B[\uDC00-\uDEBB])/),E.test(e)}const T=/^[\t\n\r\x20-\x7E]*$/;function A(e){return T.test(e)}const I=/[\u2028\u2029]/;function O(e){return I.test(e)}function M(e){return e>=11904&&e<=55215||e>=63744&&e<=64255||e>=65281&&e<=65374}function R(e){return e>=127462&&e<=127487||8986===e||8987===e||9200===e||9203===e||e>=9728&&e<=10175||11088===e||11093===e||e>=127744&&e<=128591||e>=128640&&e<=128764||e>=128992&&e<=129008||e>=129280&&e<=129535||e>=129648&&e<=129782}const D=String.fromCharCode(65279);function B(e){return!!(e&&e.length>0&&65279===e.charCodeAt(0))}function F(e){return(e%=52)<26?String.fromCharCode(97+e):String.fromCharCode(65+e-26)}function P(e,t){return 0===e?5!==t&&7!==t:(2!==e||3!==t)&&(4===e||2===e||3===e||(4===t||2===t||3===t||(8!==e||8!==t&&9!==t&&11!==t&&12!==t)&&((11!==e&&9!==e||9!==t&&10!==t)&&((12!==e&&10!==e||10!==t)&&(5!==t&&13!==t&&(7!==t&&(1!==e&&((13!==e||14!==t)&&(6!==e||6!==t)))))))))}class V{static{this._INSTANCE=null}static getInstance(){return V._INSTANCE||(V._INSTANCE=new V),V._INSTANCE}constructor(){this._data=JSON.parse("[0,0,0,51229,51255,12,44061,44087,12,127462,127487,6,7083,7085,5,47645,47671,12,54813,54839,12,128678,128678,14,3270,3270,5,9919,9923,14,45853,45879,12,49437,49463,12,53021,53047,12,71216,71218,7,128398,128399,14,129360,129374,14,2519,2519,5,4448,4519,9,9742,9742,14,12336,12336,14,44957,44983,12,46749,46775,12,48541,48567,12,50333,50359,12,52125,52151,12,53917,53943,12,69888,69890,5,73018,73018,5,127990,127990,14,128558,128559,14,128759,128760,14,129653,129655,14,2027,2035,5,2891,2892,7,3761,3761,5,6683,6683,5,8293,8293,4,9825,9826,14,9999,9999,14,43452,43453,5,44509,44535,12,45405,45431,12,46301,46327,12,47197,47223,12,48093,48119,12,48989,49015,12,49885,49911,12,50781,50807,12,51677,51703,12,52573,52599,12,53469,53495,12,54365,54391,12,65279,65279,4,70471,70472,7,72145,72147,7,119173,119179,5,127799,127818,14,128240,128244,14,128512,128512,14,128652,128652,14,128721,128722,14,129292,129292,14,129445,129450,14,129734,129743,14,1476,1477,5,2366,2368,7,2750,2752,7,3076,3076,5,3415,3415,5,4141,4144,5,6109,6109,5,6964,6964,5,7394,7400,5,9197,9198,14,9770,9770,14,9877,9877,14,9968,9969,14,10084,10084,14,43052,43052,5,43713,43713,5,44285,44311,12,44733,44759,12,45181,45207,12,45629,45655,12,46077,46103,12,46525,46551,12,46973,46999,12,47421,47447,12,47869,47895,12,48317,48343,12,48765,48791,12,49213,49239,12,49661,49687,12,50109,50135,12,50557,50583,12,51005,51031,12,51453,51479,12,51901,51927,12,52349,52375,12,52797,52823,12,53245,53271,12,53693,53719,12,54141,54167,12,54589,54615,12,55037,55063,12,69506,69509,5,70191,70193,5,70841,70841,7,71463,71467,5,72330,72342,5,94031,94031,5,123628,123631,5,127763,127765,14,127941,127941,14,128043,128062,14,128302,128317,14,128465,128467,14,128539,128539,14,128640,128640,14,128662,128662,14,128703,128703,14,128745,128745,14,129004,129007,14,129329,129330,14,129402,129402,14,129483,129483,14,129686,129704,14,130048,131069,14,173,173,4,1757,1757,1,2200,2207,5,2434,2435,7,2631,2632,5,2817,2817,5,3008,3008,5,3201,3201,5,3387,3388,5,3542,3542,5,3902,3903,7,4190,4192,5,6002,6003,5,6439,6440,5,6765,6770,7,7019,7027,5,7154,7155,7,8205,8205,13,8505,8505,14,9654,9654,14,9757,9757,14,9792,9792,14,9852,9853,14,9890,9894,14,9937,9937,14,9981,9981,14,10035,10036,14,11035,11036,14,42654,42655,5,43346,43347,7,43587,43587,5,44006,44007,7,44173,44199,12,44397,44423,12,44621,44647,12,44845,44871,12,45069,45095,12,45293,45319,12,45517,45543,12,45741,45767,12,45965,45991,12,46189,46215,12,46413,46439,12,46637,46663,12,46861,46887,12,47085,47111,12,47309,47335,12,47533,47559,12,47757,47783,12,47981,48007,12,48205,48231,12,48429,48455,12,48653,48679,12,48877,48903,12,49101,49127,12,49325,49351,12,49549,49575,12,49773,49799,12,49997,50023,12,50221,50247,12,50445,50471,12,50669,50695,12,50893,50919,12,51117,51143,12,51341,51367,12,51565,51591,12,51789,51815,12,52013,52039,12,52237,52263,12,52461,52487,12,52685,52711,12,52909,52935,12,53133,53159,12,53357,53383,12,53581,53607,12,53805,53831,12,54029,54055,12,54253,54279,12,54477,54503,12,54701,54727,12,54925,54951,12,55149,55175,12,68101,68102,5,69762,69762,7,70067,70069,7,70371,70378,5,70720,70721,7,71087,71087,5,71341,71341,5,71995,71996,5,72249,72249,7,72850,72871,5,73109,73109,5,118576,118598,5,121505,121519,5,127245,127247,14,127568,127569,14,127777,127777,14,127872,127891,14,127956,127967,14,128015,128016,14,128110,128172,14,128259,128259,14,128367,128368,14,128424,128424,14,128488,128488,14,128530,128532,14,128550,128551,14,128566,128566,14,128647,128647,14,128656,128656,14,128667,128673,14,128691,128693,14,128715,128715,14,128728,128732,14,128752,128752,14,128765,128767,14,129096,129103,14,129311,129311,14,129344,129349,14,129394,129394,14,129413,129425,14,129466,129471,14,129511,129535,14,129664,129666,14,129719,129722,14,129760,129767,14,917536,917631,5,13,13,2,1160,1161,5,1564,1564,4,1807,1807,1,2085,2087,5,2307,2307,7,2382,2383,7,2497,2500,5,2563,2563,7,2677,2677,5,2763,2764,7,2879,2879,5,2914,2915,5,3021,3021,5,3142,3144,5,3263,3263,5,3285,3286,5,3398,3400,7,3530,3530,5,3633,3633,5,3864,3865,5,3974,3975,5,4155,4156,7,4229,4230,5,5909,5909,7,6078,6085,7,6277,6278,5,6451,6456,7,6744,6750,5,6846,6846,5,6972,6972,5,7074,7077,5,7146,7148,7,7222,7223,5,7416,7417,5,8234,8238,4,8417,8417,5,9000,9000,14,9203,9203,14,9730,9731,14,9748,9749,14,9762,9763,14,9776,9783,14,9800,9811,14,9831,9831,14,9872,9873,14,9882,9882,14,9900,9903,14,9929,9933,14,9941,9960,14,9974,9974,14,9989,9989,14,10006,10006,14,10062,10062,14,10160,10160,14,11647,11647,5,12953,12953,14,43019,43019,5,43232,43249,5,43443,43443,5,43567,43568,7,43696,43696,5,43765,43765,7,44013,44013,5,44117,44143,12,44229,44255,12,44341,44367,12,44453,44479,12,44565,44591,12,44677,44703,12,44789,44815,12,44901,44927,12,45013,45039,12,45125,45151,12,45237,45263,12,45349,45375,12,45461,45487,12,45573,45599,12,45685,45711,12,45797,45823,12,45909,45935,12,46021,46047,12,46133,46159,12,46245,46271,12,46357,46383,12,46469,46495,12,46581,46607,12,46693,46719,12,46805,46831,12,46917,46943,12,47029,47055,12,47141,47167,12,47253,47279,12,47365,47391,12,47477,47503,12,47589,47615,12,47701,47727,12,47813,47839,12,47925,47951,12,48037,48063,12,48149,48175,12,48261,48287,12,48373,48399,12,48485,48511,12,48597,48623,12,48709,48735,12,48821,48847,12,48933,48959,12,49045,49071,12,49157,49183,12,49269,49295,12,49381,49407,12,49493,49519,12,49605,49631,12,49717,49743,12,49829,49855,12,49941,49967,12,50053,50079,12,50165,50191,12,50277,50303,12,50389,50415,12,50501,50527,12,50613,50639,12,50725,50751,12,50837,50863,12,50949,50975,12,51061,51087,12,51173,51199,12,51285,51311,12,51397,51423,12,51509,51535,12,51621,51647,12,51733,51759,12,51845,51871,12,51957,51983,12,52069,52095,12,52181,52207,12,52293,52319,12,52405,52431,12,52517,52543,12,52629,52655,12,52741,52767,12,52853,52879,12,52965,52991,12,53077,53103,12,53189,53215,12,53301,53327,12,53413,53439,12,53525,53551,12,53637,53663,12,53749,53775,12,53861,53887,12,53973,53999,12,54085,54111,12,54197,54223,12,54309,54335,12,54421,54447,12,54533,54559,12,54645,54671,12,54757,54783,12,54869,54895,12,54981,55007,12,55093,55119,12,55243,55291,10,66045,66045,5,68325,68326,5,69688,69702,5,69817,69818,5,69957,69958,7,70089,70092,5,70198,70199,5,70462,70462,5,70502,70508,5,70750,70750,5,70846,70846,7,71100,71101,5,71230,71230,7,71351,71351,5,71737,71738,5,72000,72000,7,72160,72160,5,72273,72278,5,72752,72758,5,72882,72883,5,73031,73031,5,73461,73462,7,94192,94193,7,119149,119149,7,121403,121452,5,122915,122916,5,126980,126980,14,127358,127359,14,127535,127535,14,127759,127759,14,127771,127771,14,127792,127793,14,127825,127867,14,127897,127899,14,127945,127945,14,127985,127986,14,128000,128007,14,128021,128021,14,128066,128100,14,128184,128235,14,128249,128252,14,128266,128276,14,128335,128335,14,128379,128390,14,128407,128419,14,128444,128444,14,128481,128481,14,128499,128499,14,128526,128526,14,128536,128536,14,128543,128543,14,128556,128556,14,128564,128564,14,128577,128580,14,128643,128645,14,128649,128649,14,128654,128654,14,128660,128660,14,128664,128664,14,128675,128675,14,128686,128689,14,128695,128696,14,128705,128709,14,128717,128719,14,128725,128725,14,128736,128741,14,128747,128748,14,128755,128755,14,128762,128762,14,128981,128991,14,129009,129023,14,129160,129167,14,129296,129304,14,129320,129327,14,129340,129342,14,129356,129356,14,129388,129392,14,129399,129400,14,129404,129407,14,129432,129442,14,129454,129455,14,129473,129474,14,129485,129487,14,129648,129651,14,129659,129660,14,129671,129679,14,129709,129711,14,129728,129730,14,129751,129753,14,129776,129782,14,917505,917505,4,917760,917999,5,10,10,3,127,159,4,768,879,5,1471,1471,5,1536,1541,1,1648,1648,5,1767,1768,5,1840,1866,5,2070,2073,5,2137,2139,5,2274,2274,1,2363,2363,7,2377,2380,7,2402,2403,5,2494,2494,5,2507,2508,7,2558,2558,5,2622,2624,7,2641,2641,5,2691,2691,7,2759,2760,5,2786,2787,5,2876,2876,5,2881,2884,5,2901,2902,5,3006,3006,5,3014,3016,7,3072,3072,5,3134,3136,5,3157,3158,5,3260,3260,5,3266,3266,5,3274,3275,7,3328,3329,5,3391,3392,7,3405,3405,5,3457,3457,5,3536,3537,7,3551,3551,5,3636,3642,5,3764,3772,5,3895,3895,5,3967,3967,7,3993,4028,5,4146,4151,5,4182,4183,7,4226,4226,5,4253,4253,5,4957,4959,5,5940,5940,7,6070,6070,7,6087,6088,7,6158,6158,4,6432,6434,5,6448,6449,7,6679,6680,5,6742,6742,5,6754,6754,5,6783,6783,5,6912,6915,5,6966,6970,5,6978,6978,5,7042,7042,7,7080,7081,5,7143,7143,7,7150,7150,7,7212,7219,5,7380,7392,5,7412,7412,5,8203,8203,4,8232,8232,4,8265,8265,14,8400,8412,5,8421,8432,5,8617,8618,14,9167,9167,14,9200,9200,14,9410,9410,14,9723,9726,14,9733,9733,14,9745,9745,14,9752,9752,14,9760,9760,14,9766,9766,14,9774,9774,14,9786,9786,14,9794,9794,14,9823,9823,14,9828,9828,14,9833,9850,14,9855,9855,14,9875,9875,14,9880,9880,14,9885,9887,14,9896,9897,14,9906,9916,14,9926,9927,14,9935,9935,14,9939,9939,14,9962,9962,14,9972,9972,14,9978,9978,14,9986,9986,14,9997,9997,14,10002,10002,14,10017,10017,14,10055,10055,14,10071,10071,14,10133,10135,14,10548,10549,14,11093,11093,14,12330,12333,5,12441,12442,5,42608,42610,5,43010,43010,5,43045,43046,5,43188,43203,7,43302,43309,5,43392,43394,5,43446,43449,5,43493,43493,5,43571,43572,7,43597,43597,7,43703,43704,5,43756,43757,5,44003,44004,7,44009,44010,7,44033,44059,12,44089,44115,12,44145,44171,12,44201,44227,12,44257,44283,12,44313,44339,12,44369,44395,12,44425,44451,12,44481,44507,12,44537,44563,12,44593,44619,12,44649,44675,12,44705,44731,12,44761,44787,12,44817,44843,12,44873,44899,12,44929,44955,12,44985,45011,12,45041,45067,12,45097,45123,12,45153,45179,12,45209,45235,12,45265,45291,12,45321,45347,12,45377,45403,12,45433,45459,12,45489,45515,12,45545,45571,12,45601,45627,12,45657,45683,12,45713,45739,12,45769,45795,12,45825,45851,12,45881,45907,12,45937,45963,12,45993,46019,12,46049,46075,12,46105,46131,12,46161,46187,12,46217,46243,12,46273,46299,12,46329,46355,12,46385,46411,12,46441,46467,12,46497,46523,12,46553,46579,12,46609,46635,12,46665,46691,12,46721,46747,12,46777,46803,12,46833,46859,12,46889,46915,12,46945,46971,12,47001,47027,12,47057,47083,12,47113,47139,12,47169,47195,12,47225,47251,12,47281,47307,12,47337,47363,12,47393,47419,12,47449,47475,12,47505,47531,12,47561,47587,12,47617,47643,12,47673,47699,12,47729,47755,12,47785,47811,12,47841,47867,12,47897,47923,12,47953,47979,12,48009,48035,12,48065,48091,12,48121,48147,12,48177,48203,12,48233,48259,12,48289,48315,12,48345,48371,12,48401,48427,12,48457,48483,12,48513,48539,12,48569,48595,12,48625,48651,12,48681,48707,12,48737,48763,12,48793,48819,12,48849,48875,12,48905,48931,12,48961,48987,12,49017,49043,12,49073,49099,12,49129,49155,12,49185,49211,12,49241,49267,12,49297,49323,12,49353,49379,12,49409,49435,12,49465,49491,12,49521,49547,12,49577,49603,12,49633,49659,12,49689,49715,12,49745,49771,12,49801,49827,12,49857,49883,12,49913,49939,12,49969,49995,12,50025,50051,12,50081,50107,12,50137,50163,12,50193,50219,12,50249,50275,12,50305,50331,12,50361,50387,12,50417,50443,12,50473,50499,12,50529,50555,12,50585,50611,12,50641,50667,12,50697,50723,12,50753,50779,12,50809,50835,12,50865,50891,12,50921,50947,12,50977,51003,12,51033,51059,12,51089,51115,12,51145,51171,12,51201,51227,12,51257,51283,12,51313,51339,12,51369,51395,12,51425,51451,12,51481,51507,12,51537,51563,12,51593,51619,12,51649,51675,12,51705,51731,12,51761,51787,12,51817,51843,12,51873,51899,12,51929,51955,12,51985,52011,12,52041,52067,12,52097,52123,12,52153,52179,12,52209,52235,12,52265,52291,12,52321,52347,12,52377,52403,12,52433,52459,12,52489,52515,12,52545,52571,12,52601,52627,12,52657,52683,12,52713,52739,12,52769,52795,12,52825,52851,12,52881,52907,12,52937,52963,12,52993,53019,12,53049,53075,12,53105,53131,12,53161,53187,12,53217,53243,12,53273,53299,12,53329,53355,12,53385,53411,12,53441,53467,12,53497,53523,12,53553,53579,12,53609,53635,12,53665,53691,12,53721,53747,12,53777,53803,12,53833,53859,12,53889,53915,12,53945,53971,12,54001,54027,12,54057,54083,12,54113,54139,12,54169,54195,12,54225,54251,12,54281,54307,12,54337,54363,12,54393,54419,12,54449,54475,12,54505,54531,12,54561,54587,12,54617,54643,12,54673,54699,12,54729,54755,12,54785,54811,12,54841,54867,12,54897,54923,12,54953,54979,12,55009,55035,12,55065,55091,12,55121,55147,12,55177,55203,12,65024,65039,5,65520,65528,4,66422,66426,5,68152,68154,5,69291,69292,5,69633,69633,5,69747,69748,5,69811,69814,5,69826,69826,5,69932,69932,7,70016,70017,5,70079,70080,7,70095,70095,5,70196,70196,5,70367,70367,5,70402,70403,7,70464,70464,5,70487,70487,5,70709,70711,7,70725,70725,7,70833,70834,7,70843,70844,7,70849,70849,7,71090,71093,5,71103,71104,5,71227,71228,7,71339,71339,5,71344,71349,5,71458,71461,5,71727,71735,5,71985,71989,7,71998,71998,5,72002,72002,7,72154,72155,5,72193,72202,5,72251,72254,5,72281,72283,5,72344,72345,5,72766,72766,7,72874,72880,5,72885,72886,5,73023,73029,5,73104,73105,5,73111,73111,5,92912,92916,5,94095,94098,5,113824,113827,4,119142,119142,7,119155,119162,4,119362,119364,5,121476,121476,5,122888,122904,5,123184,123190,5,125252,125258,5,127183,127183,14,127340,127343,14,127377,127386,14,127491,127503,14,127548,127551,14,127744,127756,14,127761,127761,14,127769,127769,14,127773,127774,14,127780,127788,14,127796,127797,14,127820,127823,14,127869,127869,14,127894,127895,14,127902,127903,14,127943,127943,14,127947,127950,14,127972,127972,14,127988,127988,14,127992,127994,14,128009,128011,14,128019,128019,14,128023,128041,14,128064,128064,14,128102,128107,14,128174,128181,14,128238,128238,14,128246,128247,14,128254,128254,14,128264,128264,14,128278,128299,14,128329,128330,14,128348,128359,14,128371,128377,14,128392,128393,14,128401,128404,14,128421,128421,14,128433,128434,14,128450,128452,14,128476,128478,14,128483,128483,14,128495,128495,14,128506,128506,14,128519,128520,14,128528,128528,14,128534,128534,14,128538,128538,14,128540,128542,14,128544,128549,14,128552,128555,14,128557,128557,14,128560,128563,14,128565,128565,14,128567,128576,14,128581,128591,14,128641,128642,14,128646,128646,14,128648,128648,14,128650,128651,14,128653,128653,14,128655,128655,14,128657,128659,14,128661,128661,14,128663,128663,14,128665,128666,14,128674,128674,14,128676,128677,14,128679,128685,14,128690,128690,14,128694,128694,14,128697,128702,14,128704,128704,14,128710,128714,14,128716,128716,14,128720,128720,14,128723,128724,14,128726,128727,14,128733,128735,14,128742,128744,14,128746,128746,14,128749,128751,14,128753,128754,14,128756,128758,14,128761,128761,14,128763,128764,14,128884,128895,14,128992,129003,14,129008,129008,14,129036,129039,14,129114,129119,14,129198,129279,14,129293,129295,14,129305,129310,14,129312,129319,14,129328,129328,14,129331,129338,14,129343,129343,14,129351,129355,14,129357,129359,14,129375,129387,14,129393,129393,14,129395,129398,14,129401,129401,14,129403,129403,14,129408,129412,14,129426,129431,14,129443,129444,14,129451,129453,14,129456,129465,14,129472,129472,14,129475,129482,14,129484,129484,14,129488,129510,14,129536,129647,14,129652,129652,14,129656,129658,14,129661,129663,14,129667,129670,14,129680,129685,14,129705,129708,14,129712,129718,14,129723,129727,14,129731,129733,14,129744,129750,14,129754,129759,14,129768,129775,14,129783,129791,14,917504,917504,4,917506,917535,4,917632,917759,4,918000,921599,4,0,9,4,11,12,4,14,31,4,169,169,14,174,174,14,1155,1159,5,1425,1469,5,1473,1474,5,1479,1479,5,1552,1562,5,1611,1631,5,1750,1756,5,1759,1764,5,1770,1773,5,1809,1809,5,1958,1968,5,2045,2045,5,2075,2083,5,2089,2093,5,2192,2193,1,2250,2273,5,2275,2306,5,2362,2362,5,2364,2364,5,2369,2376,5,2381,2381,5,2385,2391,5,2433,2433,5,2492,2492,5,2495,2496,7,2503,2504,7,2509,2509,5,2530,2531,5,2561,2562,5,2620,2620,5,2625,2626,5,2635,2637,5,2672,2673,5,2689,2690,5,2748,2748,5,2753,2757,5,2761,2761,7,2765,2765,5,2810,2815,5,2818,2819,7,2878,2878,5,2880,2880,7,2887,2888,7,2893,2893,5,2903,2903,5,2946,2946,5,3007,3007,7,3009,3010,7,3018,3020,7,3031,3031,5,3073,3075,7,3132,3132,5,3137,3140,7,3146,3149,5,3170,3171,5,3202,3203,7,3262,3262,7,3264,3265,7,3267,3268,7,3271,3272,7,3276,3277,5,3298,3299,5,3330,3331,7,3390,3390,5,3393,3396,5,3402,3404,7,3406,3406,1,3426,3427,5,3458,3459,7,3535,3535,5,3538,3540,5,3544,3550,7,3570,3571,7,3635,3635,7,3655,3662,5,3763,3763,7,3784,3789,5,3893,3893,5,3897,3897,5,3953,3966,5,3968,3972,5,3981,3991,5,4038,4038,5,4145,4145,7,4153,4154,5,4157,4158,5,4184,4185,5,4209,4212,5,4228,4228,7,4237,4237,5,4352,4447,8,4520,4607,10,5906,5908,5,5938,5939,5,5970,5971,5,6068,6069,5,6071,6077,5,6086,6086,5,6089,6099,5,6155,6157,5,6159,6159,5,6313,6313,5,6435,6438,7,6441,6443,7,6450,6450,5,6457,6459,5,6681,6682,7,6741,6741,7,6743,6743,7,6752,6752,5,6757,6764,5,6771,6780,5,6832,6845,5,6847,6862,5,6916,6916,7,6965,6965,5,6971,6971,7,6973,6977,7,6979,6980,7,7040,7041,5,7073,7073,7,7078,7079,7,7082,7082,7,7142,7142,5,7144,7145,5,7149,7149,5,7151,7153,5,7204,7211,7,7220,7221,7,7376,7378,5,7393,7393,7,7405,7405,5,7415,7415,7,7616,7679,5,8204,8204,5,8206,8207,4,8233,8233,4,8252,8252,14,8288,8292,4,8294,8303,4,8413,8416,5,8418,8420,5,8482,8482,14,8596,8601,14,8986,8987,14,9096,9096,14,9193,9196,14,9199,9199,14,9201,9202,14,9208,9210,14,9642,9643,14,9664,9664,14,9728,9729,14,9732,9732,14,9735,9741,14,9743,9744,14,9746,9746,14,9750,9751,14,9753,9756,14,9758,9759,14,9761,9761,14,9764,9765,14,9767,9769,14,9771,9773,14,9775,9775,14,9784,9785,14,9787,9791,14,9793,9793,14,9795,9799,14,9812,9822,14,9824,9824,14,9827,9827,14,9829,9830,14,9832,9832,14,9851,9851,14,9854,9854,14,9856,9861,14,9874,9874,14,9876,9876,14,9878,9879,14,9881,9881,14,9883,9884,14,9888,9889,14,9895,9895,14,9898,9899,14,9904,9905,14,9917,9918,14,9924,9925,14,9928,9928,14,9934,9934,14,9936,9936,14,9938,9938,14,9940,9940,14,9961,9961,14,9963,9967,14,9970,9971,14,9973,9973,14,9975,9977,14,9979,9980,14,9982,9985,14,9987,9988,14,9992,9996,14,9998,9998,14,10000,10001,14,10004,10004,14,10013,10013,14,10024,10024,14,10052,10052,14,10060,10060,14,10067,10069,14,10083,10083,14,10085,10087,14,10145,10145,14,10175,10175,14,11013,11015,14,11088,11088,14,11503,11505,5,11744,11775,5,12334,12335,5,12349,12349,14,12951,12951,14,42607,42607,5,42612,42621,5,42736,42737,5,43014,43014,5,43043,43044,7,43047,43047,7,43136,43137,7,43204,43205,5,43263,43263,5,43335,43345,5,43360,43388,8,43395,43395,7,43444,43445,7,43450,43451,7,43454,43456,7,43561,43566,5,43569,43570,5,43573,43574,5,43596,43596,5,43644,43644,5,43698,43700,5,43710,43711,5,43755,43755,7,43758,43759,7,43766,43766,5,44005,44005,5,44008,44008,5,44012,44012,7,44032,44032,11,44060,44060,11,44088,44088,11,44116,44116,11,44144,44144,11,44172,44172,11,44200,44200,11,44228,44228,11,44256,44256,11,44284,44284,11,44312,44312,11,44340,44340,11,44368,44368,11,44396,44396,11,44424,44424,11,44452,44452,11,44480,44480,11,44508,44508,11,44536,44536,11,44564,44564,11,44592,44592,11,44620,44620,11,44648,44648,11,44676,44676,11,44704,44704,11,44732,44732,11,44760,44760,11,44788,44788,11,44816,44816,11,44844,44844,11,44872,44872,11,44900,44900,11,44928,44928,11,44956,44956,11,44984,44984,11,45012,45012,11,45040,45040,11,45068,45068,11,45096,45096,11,45124,45124,11,45152,45152,11,45180,45180,11,45208,45208,11,45236,45236,11,45264,45264,11,45292,45292,11,45320,45320,11,45348,45348,11,45376,45376,11,45404,45404,11,45432,45432,11,45460,45460,11,45488,45488,11,45516,45516,11,45544,45544,11,45572,45572,11,45600,45600,11,45628,45628,11,45656,45656,11,45684,45684,11,45712,45712,11,45740,45740,11,45768,45768,11,45796,45796,11,45824,45824,11,45852,45852,11,45880,45880,11,45908,45908,11,45936,45936,11,45964,45964,11,45992,45992,11,46020,46020,11,46048,46048,11,46076,46076,11,46104,46104,11,46132,46132,11,46160,46160,11,46188,46188,11,46216,46216,11,46244,46244,11,46272,46272,11,46300,46300,11,46328,46328,11,46356,46356,11,46384,46384,11,46412,46412,11,46440,46440,11,46468,46468,11,46496,46496,11,46524,46524,11,46552,46552,11,46580,46580,11,46608,46608,11,46636,46636,11,46664,46664,11,46692,46692,11,46720,46720,11,46748,46748,11,46776,46776,11,46804,46804,11,46832,46832,11,46860,46860,11,46888,46888,11,46916,46916,11,46944,46944,11,46972,46972,11,47000,47000,11,47028,47028,11,47056,47056,11,47084,47084,11,47112,47112,11,47140,47140,11,47168,47168,11,47196,47196,11,47224,47224,11,47252,47252,11,47280,47280,11,47308,47308,11,47336,47336,11,47364,47364,11,47392,47392,11,47420,47420,11,47448,47448,11,47476,47476,11,47504,47504,11,47532,47532,11,47560,47560,11,47588,47588,11,47616,47616,11,47644,47644,11,47672,47672,11,47700,47700,11,47728,47728,11,47756,47756,11,47784,47784,11,47812,47812,11,47840,47840,11,47868,47868,11,47896,47896,11,47924,47924,11,47952,47952,11,47980,47980,11,48008,48008,11,48036,48036,11,48064,48064,11,48092,48092,11,48120,48120,11,48148,48148,11,48176,48176,11,48204,48204,11,48232,48232,11,48260,48260,11,48288,48288,11,48316,48316,11,48344,48344,11,48372,48372,11,48400,48400,11,48428,48428,11,48456,48456,11,48484,48484,11,48512,48512,11,48540,48540,11,48568,48568,11,48596,48596,11,48624,48624,11,48652,48652,11,48680,48680,11,48708,48708,11,48736,48736,11,48764,48764,11,48792,48792,11,48820,48820,11,48848,48848,11,48876,48876,11,48904,48904,11,48932,48932,11,48960,48960,11,48988,48988,11,49016,49016,11,49044,49044,11,49072,49072,11,49100,49100,11,49128,49128,11,49156,49156,11,49184,49184,11,49212,49212,11,49240,49240,11,49268,49268,11,49296,49296,11,49324,49324,11,49352,49352,11,49380,49380,11,49408,49408,11,49436,49436,11,49464,49464,11,49492,49492,11,49520,49520,11,49548,49548,11,49576,49576,11,49604,49604,11,49632,49632,11,49660,49660,11,49688,49688,11,49716,49716,11,49744,49744,11,49772,49772,11,49800,49800,11,49828,49828,11,49856,49856,11,49884,49884,11,49912,49912,11,49940,49940,11,49968,49968,11,49996,49996,11,50024,50024,11,50052,50052,11,50080,50080,11,50108,50108,11,50136,50136,11,50164,50164,11,50192,50192,11,50220,50220,11,50248,50248,11,50276,50276,11,50304,50304,11,50332,50332,11,50360,50360,11,50388,50388,11,50416,50416,11,50444,50444,11,50472,50472,11,50500,50500,11,50528,50528,11,50556,50556,11,50584,50584,11,50612,50612,11,50640,50640,11,50668,50668,11,50696,50696,11,50724,50724,11,50752,50752,11,50780,50780,11,50808,50808,11,50836,50836,11,50864,50864,11,50892,50892,11,50920,50920,11,50948,50948,11,50976,50976,11,51004,51004,11,51032,51032,11,51060,51060,11,51088,51088,11,51116,51116,11,51144,51144,11,51172,51172,11,51200,51200,11,51228,51228,11,51256,51256,11,51284,51284,11,51312,51312,11,51340,51340,11,51368,51368,11,51396,51396,11,51424,51424,11,51452,51452,11,51480,51480,11,51508,51508,11,51536,51536,11,51564,51564,11,51592,51592,11,51620,51620,11,51648,51648,11,51676,51676,11,51704,51704,11,51732,51732,11,51760,51760,11,51788,51788,11,51816,51816,11,51844,51844,11,51872,51872,11,51900,51900,11,51928,51928,11,51956,51956,11,51984,51984,11,52012,52012,11,52040,52040,11,52068,52068,11,52096,52096,11,52124,52124,11,52152,52152,11,52180,52180,11,52208,52208,11,52236,52236,11,52264,52264,11,52292,52292,11,52320,52320,11,52348,52348,11,52376,52376,11,52404,52404,11,52432,52432,11,52460,52460,11,52488,52488,11,52516,52516,11,52544,52544,11,52572,52572,11,52600,52600,11,52628,52628,11,52656,52656,11,52684,52684,11,52712,52712,11,52740,52740,11,52768,52768,11,52796,52796,11,52824,52824,11,52852,52852,11,52880,52880,11,52908,52908,11,52936,52936,11,52964,52964,11,52992,52992,11,53020,53020,11,53048,53048,11,53076,53076,11,53104,53104,11,53132,53132,11,53160,53160,11,53188,53188,11,53216,53216,11,53244,53244,11,53272,53272,11,53300,53300,11,53328,53328,11,53356,53356,11,53384,53384,11,53412,53412,11,53440,53440,11,53468,53468,11,53496,53496,11,53524,53524,11,53552,53552,11,53580,53580,11,53608,53608,11,53636,53636,11,53664,53664,11,53692,53692,11,53720,53720,11,53748,53748,11,53776,53776,11,53804,53804,11,53832,53832,11,53860,53860,11,53888,53888,11,53916,53916,11,53944,53944,11,53972,53972,11,54000,54000,11,54028,54028,11,54056,54056,11,54084,54084,11,54112,54112,11,54140,54140,11,54168,54168,11,54196,54196,11,54224,54224,11,54252,54252,11,54280,54280,11,54308,54308,11,54336,54336,11,54364,54364,11,54392,54392,11,54420,54420,11,54448,54448,11,54476,54476,11,54504,54504,11,54532,54532,11,54560,54560,11,54588,54588,11,54616,54616,11,54644,54644,11,54672,54672,11,54700,54700,11,54728,54728,11,54756,54756,11,54784,54784,11,54812,54812,11,54840,54840,11,54868,54868,11,54896,54896,11,54924,54924,11,54952,54952,11,54980,54980,11,55008,55008,11,55036,55036,11,55064,55064,11,55092,55092,11,55120,55120,11,55148,55148,11,55176,55176,11,55216,55238,9,64286,64286,5,65056,65071,5,65438,65439,5,65529,65531,4,66272,66272,5,68097,68099,5,68108,68111,5,68159,68159,5,68900,68903,5,69446,69456,5,69632,69632,7,69634,69634,7,69744,69744,5,69759,69761,5,69808,69810,7,69815,69816,7,69821,69821,1,69837,69837,1,69927,69931,5,69933,69940,5,70003,70003,5,70018,70018,7,70070,70078,5,70082,70083,1,70094,70094,7,70188,70190,7,70194,70195,7,70197,70197,7,70206,70206,5,70368,70370,7,70400,70401,5,70459,70460,5,70463,70463,7,70465,70468,7,70475,70477,7,70498,70499,7,70512,70516,5,70712,70719,5,70722,70724,5,70726,70726,5,70832,70832,5,70835,70840,5,70842,70842,5,70845,70845,5,70847,70848,5,70850,70851,5,71088,71089,7,71096,71099,7,71102,71102,7,71132,71133,5,71219,71226,5,71229,71229,5,71231,71232,5,71340,71340,7,71342,71343,7,71350,71350,7,71453,71455,5,71462,71462,7,71724,71726,7,71736,71736,7,71984,71984,5,71991,71992,7,71997,71997,7,71999,71999,1,72001,72001,1,72003,72003,5,72148,72151,5,72156,72159,7,72164,72164,7,72243,72248,5,72250,72250,1,72263,72263,5,72279,72280,7,72324,72329,1,72343,72343,7,72751,72751,7,72760,72765,5,72767,72767,5,72873,72873,7,72881,72881,7,72884,72884,7,73009,73014,5,73020,73021,5,73030,73030,1,73098,73102,7,73107,73108,7,73110,73110,7,73459,73460,5,78896,78904,4,92976,92982,5,94033,94087,7,94180,94180,5,113821,113822,5,118528,118573,5,119141,119141,5,119143,119145,5,119150,119154,5,119163,119170,5,119210,119213,5,121344,121398,5,121461,121461,5,121499,121503,5,122880,122886,5,122907,122913,5,122918,122922,5,123566,123566,5,125136,125142,5,126976,126979,14,126981,127182,14,127184,127231,14,127279,127279,14,127344,127345,14,127374,127374,14,127405,127461,14,127489,127490,14,127514,127514,14,127538,127546,14,127561,127567,14,127570,127743,14,127757,127758,14,127760,127760,14,127762,127762,14,127766,127768,14,127770,127770,14,127772,127772,14,127775,127776,14,127778,127779,14,127789,127791,14,127794,127795,14,127798,127798,14,127819,127819,14,127824,127824,14,127868,127868,14,127870,127871,14,127892,127893,14,127896,127896,14,127900,127901,14,127904,127940,14,127942,127942,14,127944,127944,14,127946,127946,14,127951,127955,14,127968,127971,14,127973,127984,14,127987,127987,14,127989,127989,14,127991,127991,14,127995,127999,5,128008,128008,14,128012,128014,14,128017,128018,14,128020,128020,14,128022,128022,14,128042,128042,14,128063,128063,14,128065,128065,14,128101,128101,14,128108,128109,14,128173,128173,14,128182,128183,14,128236,128237,14,128239,128239,14,128245,128245,14,128248,128248,14,128253,128253,14,128255,128258,14,128260,128263,14,128265,128265,14,128277,128277,14,128300,128301,14,128326,128328,14,128331,128334,14,128336,128347,14,128360,128366,14,128369,128370,14,128378,128378,14,128391,128391,14,128394,128397,14,128400,128400,14,128405,128406,14,128420,128420,14,128422,128423,14,128425,128432,14,128435,128443,14,128445,128449,14,128453,128464,14,128468,128475,14,128479,128480,14,128482,128482,14,128484,128487,14,128489,128494,14,128496,128498,14,128500,128505,14,128507,128511,14,128513,128518,14,128521,128525,14,128527,128527,14,128529,128529,14,128533,128533,14,128535,128535,14,128537,128537,14]")}getGraphemeBreakType(e){if(e<32)return 10===e?3:13===e?2:4;if(e<127)return 0;const t=this._data,n=t.length/3;let r=1;for(;r<=n;)if(et[3*r+1]))return t[3*r+2];r=2*r+1}return 0}}class z{static{this.ambiguousCharacterData=new i.d((()=>JSON.parse('{"_common":[8232,32,8233,32,5760,32,8192,32,8193,32,8194,32,8195,32,8196,32,8197,32,8198,32,8200,32,8201,32,8202,32,8287,32,8199,32,8239,32,2042,95,65101,95,65102,95,65103,95,8208,45,8209,45,8210,45,65112,45,1748,45,8259,45,727,45,8722,45,10134,45,11450,45,1549,44,1643,44,8218,44,184,44,42233,44,894,59,2307,58,2691,58,1417,58,1795,58,1796,58,5868,58,65072,58,6147,58,6153,58,8282,58,1475,58,760,58,42889,58,8758,58,720,58,42237,58,451,33,11601,33,660,63,577,63,2429,63,5038,63,42731,63,119149,46,8228,46,1793,46,1794,46,42510,46,68176,46,1632,46,1776,46,42232,46,1373,96,65287,96,8219,96,8242,96,1370,96,1523,96,8175,96,65344,96,900,96,8189,96,8125,96,8127,96,8190,96,697,96,884,96,712,96,714,96,715,96,756,96,699,96,701,96,700,96,702,96,42892,96,1497,96,2036,96,2037,96,5194,96,5836,96,94033,96,94034,96,65339,91,10088,40,10098,40,12308,40,64830,40,65341,93,10089,41,10099,41,12309,41,64831,41,10100,123,119060,123,10101,125,65342,94,8270,42,1645,42,8727,42,66335,42,5941,47,8257,47,8725,47,8260,47,9585,47,10187,47,10744,47,119354,47,12755,47,12339,47,11462,47,20031,47,12035,47,65340,92,65128,92,8726,92,10189,92,10741,92,10745,92,119311,92,119355,92,12756,92,20022,92,12034,92,42872,38,708,94,710,94,5869,43,10133,43,66203,43,8249,60,10094,60,706,60,119350,60,5176,60,5810,60,5120,61,11840,61,12448,61,42239,61,8250,62,10095,62,707,62,119351,62,5171,62,94015,62,8275,126,732,126,8128,126,8764,126,65372,124,65293,45,120784,50,120794,50,120804,50,120814,50,120824,50,130034,50,42842,50,423,50,1000,50,42564,50,5311,50,42735,50,119302,51,120785,51,120795,51,120805,51,120815,51,120825,51,130035,51,42923,51,540,51,439,51,42858,51,11468,51,1248,51,94011,51,71882,51,120786,52,120796,52,120806,52,120816,52,120826,52,130036,52,5070,52,71855,52,120787,53,120797,53,120807,53,120817,53,120827,53,130037,53,444,53,71867,53,120788,54,120798,54,120808,54,120818,54,120828,54,130038,54,11474,54,5102,54,71893,54,119314,55,120789,55,120799,55,120809,55,120819,55,120829,55,130039,55,66770,55,71878,55,2819,56,2538,56,2666,56,125131,56,120790,56,120800,56,120810,56,120820,56,120830,56,130040,56,547,56,546,56,66330,56,2663,57,2920,57,2541,57,3437,57,120791,57,120801,57,120811,57,120821,57,120831,57,130041,57,42862,57,11466,57,71884,57,71852,57,71894,57,9082,97,65345,97,119834,97,119886,97,119938,97,119990,97,120042,97,120094,97,120146,97,120198,97,120250,97,120302,97,120354,97,120406,97,120458,97,593,97,945,97,120514,97,120572,97,120630,97,120688,97,120746,97,65313,65,119808,65,119860,65,119912,65,119964,65,120016,65,120068,65,120120,65,120172,65,120224,65,120276,65,120328,65,120380,65,120432,65,913,65,120488,65,120546,65,120604,65,120662,65,120720,65,5034,65,5573,65,42222,65,94016,65,66208,65,119835,98,119887,98,119939,98,119991,98,120043,98,120095,98,120147,98,120199,98,120251,98,120303,98,120355,98,120407,98,120459,98,388,98,5071,98,5234,98,5551,98,65314,66,8492,66,119809,66,119861,66,119913,66,120017,66,120069,66,120121,66,120173,66,120225,66,120277,66,120329,66,120381,66,120433,66,42932,66,914,66,120489,66,120547,66,120605,66,120663,66,120721,66,5108,66,5623,66,42192,66,66178,66,66209,66,66305,66,65347,99,8573,99,119836,99,119888,99,119940,99,119992,99,120044,99,120096,99,120148,99,120200,99,120252,99,120304,99,120356,99,120408,99,120460,99,7428,99,1010,99,11429,99,43951,99,66621,99,128844,67,71922,67,71913,67,65315,67,8557,67,8450,67,8493,67,119810,67,119862,67,119914,67,119966,67,120018,67,120174,67,120226,67,120278,67,120330,67,120382,67,120434,67,1017,67,11428,67,5087,67,42202,67,66210,67,66306,67,66581,67,66844,67,8574,100,8518,100,119837,100,119889,100,119941,100,119993,100,120045,100,120097,100,120149,100,120201,100,120253,100,120305,100,120357,100,120409,100,120461,100,1281,100,5095,100,5231,100,42194,100,8558,68,8517,68,119811,68,119863,68,119915,68,119967,68,120019,68,120071,68,120123,68,120175,68,120227,68,120279,68,120331,68,120383,68,120435,68,5024,68,5598,68,5610,68,42195,68,8494,101,65349,101,8495,101,8519,101,119838,101,119890,101,119942,101,120046,101,120098,101,120150,101,120202,101,120254,101,120306,101,120358,101,120410,101,120462,101,43826,101,1213,101,8959,69,65317,69,8496,69,119812,69,119864,69,119916,69,120020,69,120072,69,120124,69,120176,69,120228,69,120280,69,120332,69,120384,69,120436,69,917,69,120492,69,120550,69,120608,69,120666,69,120724,69,11577,69,5036,69,42224,69,71846,69,71854,69,66182,69,119839,102,119891,102,119943,102,119995,102,120047,102,120099,102,120151,102,120203,102,120255,102,120307,102,120359,102,120411,102,120463,102,43829,102,42905,102,383,102,7837,102,1412,102,119315,70,8497,70,119813,70,119865,70,119917,70,120021,70,120073,70,120125,70,120177,70,120229,70,120281,70,120333,70,120385,70,120437,70,42904,70,988,70,120778,70,5556,70,42205,70,71874,70,71842,70,66183,70,66213,70,66853,70,65351,103,8458,103,119840,103,119892,103,119944,103,120048,103,120100,103,120152,103,120204,103,120256,103,120308,103,120360,103,120412,103,120464,103,609,103,7555,103,397,103,1409,103,119814,71,119866,71,119918,71,119970,71,120022,71,120074,71,120126,71,120178,71,120230,71,120282,71,120334,71,120386,71,120438,71,1292,71,5056,71,5107,71,42198,71,65352,104,8462,104,119841,104,119945,104,119997,104,120049,104,120101,104,120153,104,120205,104,120257,104,120309,104,120361,104,120413,104,120465,104,1211,104,1392,104,5058,104,65320,72,8459,72,8460,72,8461,72,119815,72,119867,72,119919,72,120023,72,120179,72,120231,72,120283,72,120335,72,120387,72,120439,72,919,72,120494,72,120552,72,120610,72,120668,72,120726,72,11406,72,5051,72,5500,72,42215,72,66255,72,731,105,9075,105,65353,105,8560,105,8505,105,8520,105,119842,105,119894,105,119946,105,119998,105,120050,105,120102,105,120154,105,120206,105,120258,105,120310,105,120362,105,120414,105,120466,105,120484,105,618,105,617,105,953,105,8126,105,890,105,120522,105,120580,105,120638,105,120696,105,120754,105,1110,105,42567,105,1231,105,43893,105,5029,105,71875,105,65354,106,8521,106,119843,106,119895,106,119947,106,119999,106,120051,106,120103,106,120155,106,120207,106,120259,106,120311,106,120363,106,120415,106,120467,106,1011,106,1112,106,65322,74,119817,74,119869,74,119921,74,119973,74,120025,74,120077,74,120129,74,120181,74,120233,74,120285,74,120337,74,120389,74,120441,74,42930,74,895,74,1032,74,5035,74,5261,74,42201,74,119844,107,119896,107,119948,107,120000,107,120052,107,120104,107,120156,107,120208,107,120260,107,120312,107,120364,107,120416,107,120468,107,8490,75,65323,75,119818,75,119870,75,119922,75,119974,75,120026,75,120078,75,120130,75,120182,75,120234,75,120286,75,120338,75,120390,75,120442,75,922,75,120497,75,120555,75,120613,75,120671,75,120729,75,11412,75,5094,75,5845,75,42199,75,66840,75,1472,108,8739,73,9213,73,65512,73,1633,108,1777,73,66336,108,125127,108,120783,73,120793,73,120803,73,120813,73,120823,73,130033,73,65321,73,8544,73,8464,73,8465,73,119816,73,119868,73,119920,73,120024,73,120128,73,120180,73,120232,73,120284,73,120336,73,120388,73,120440,73,65356,108,8572,73,8467,108,119845,108,119897,108,119949,108,120001,108,120053,108,120105,73,120157,73,120209,73,120261,73,120313,73,120365,73,120417,73,120469,73,448,73,120496,73,120554,73,120612,73,120670,73,120728,73,11410,73,1030,73,1216,73,1493,108,1503,108,1575,108,126464,108,126592,108,65166,108,65165,108,1994,108,11599,73,5825,73,42226,73,93992,73,66186,124,66313,124,119338,76,8556,76,8466,76,119819,76,119871,76,119923,76,120027,76,120079,76,120131,76,120183,76,120235,76,120287,76,120339,76,120391,76,120443,76,11472,76,5086,76,5290,76,42209,76,93974,76,71843,76,71858,76,66587,76,66854,76,65325,77,8559,77,8499,77,119820,77,119872,77,119924,77,120028,77,120080,77,120132,77,120184,77,120236,77,120288,77,120340,77,120392,77,120444,77,924,77,120499,77,120557,77,120615,77,120673,77,120731,77,1018,77,11416,77,5047,77,5616,77,5846,77,42207,77,66224,77,66321,77,119847,110,119899,110,119951,110,120003,110,120055,110,120107,110,120159,110,120211,110,120263,110,120315,110,120367,110,120419,110,120471,110,1400,110,1404,110,65326,78,8469,78,119821,78,119873,78,119925,78,119977,78,120029,78,120081,78,120185,78,120237,78,120289,78,120341,78,120393,78,120445,78,925,78,120500,78,120558,78,120616,78,120674,78,120732,78,11418,78,42208,78,66835,78,3074,111,3202,111,3330,111,3458,111,2406,111,2662,111,2790,111,3046,111,3174,111,3302,111,3430,111,3664,111,3792,111,4160,111,1637,111,1781,111,65359,111,8500,111,119848,111,119900,111,119952,111,120056,111,120108,111,120160,111,120212,111,120264,111,120316,111,120368,111,120420,111,120472,111,7439,111,7441,111,43837,111,959,111,120528,111,120586,111,120644,111,120702,111,120760,111,963,111,120532,111,120590,111,120648,111,120706,111,120764,111,11423,111,4351,111,1413,111,1505,111,1607,111,126500,111,126564,111,126596,111,65259,111,65260,111,65258,111,65257,111,1726,111,64428,111,64429,111,64427,111,64426,111,1729,111,64424,111,64425,111,64423,111,64422,111,1749,111,3360,111,4125,111,66794,111,71880,111,71895,111,66604,111,1984,79,2534,79,2918,79,12295,79,70864,79,71904,79,120782,79,120792,79,120802,79,120812,79,120822,79,130032,79,65327,79,119822,79,119874,79,119926,79,119978,79,120030,79,120082,79,120134,79,120186,79,120238,79,120290,79,120342,79,120394,79,120446,79,927,79,120502,79,120560,79,120618,79,120676,79,120734,79,11422,79,1365,79,11604,79,4816,79,2848,79,66754,79,42227,79,71861,79,66194,79,66219,79,66564,79,66838,79,9076,112,65360,112,119849,112,119901,112,119953,112,120005,112,120057,112,120109,112,120161,112,120213,112,120265,112,120317,112,120369,112,120421,112,120473,112,961,112,120530,112,120544,112,120588,112,120602,112,120646,112,120660,112,120704,112,120718,112,120762,112,120776,112,11427,112,65328,80,8473,80,119823,80,119875,80,119927,80,119979,80,120031,80,120083,80,120187,80,120239,80,120291,80,120343,80,120395,80,120447,80,929,80,120504,80,120562,80,120620,80,120678,80,120736,80,11426,80,5090,80,5229,80,42193,80,66197,80,119850,113,119902,113,119954,113,120006,113,120058,113,120110,113,120162,113,120214,113,120266,113,120318,113,120370,113,120422,113,120474,113,1307,113,1379,113,1382,113,8474,81,119824,81,119876,81,119928,81,119980,81,120032,81,120084,81,120188,81,120240,81,120292,81,120344,81,120396,81,120448,81,11605,81,119851,114,119903,114,119955,114,120007,114,120059,114,120111,114,120163,114,120215,114,120267,114,120319,114,120371,114,120423,114,120475,114,43847,114,43848,114,7462,114,11397,114,43905,114,119318,82,8475,82,8476,82,8477,82,119825,82,119877,82,119929,82,120033,82,120189,82,120241,82,120293,82,120345,82,120397,82,120449,82,422,82,5025,82,5074,82,66740,82,5511,82,42211,82,94005,82,65363,115,119852,115,119904,115,119956,115,120008,115,120060,115,120112,115,120164,115,120216,115,120268,115,120320,115,120372,115,120424,115,120476,115,42801,115,445,115,1109,115,43946,115,71873,115,66632,115,65331,83,119826,83,119878,83,119930,83,119982,83,120034,83,120086,83,120138,83,120190,83,120242,83,120294,83,120346,83,120398,83,120450,83,1029,83,1359,83,5077,83,5082,83,42210,83,94010,83,66198,83,66592,83,119853,116,119905,116,119957,116,120009,116,120061,116,120113,116,120165,116,120217,116,120269,116,120321,116,120373,116,120425,116,120477,116,8868,84,10201,84,128872,84,65332,84,119827,84,119879,84,119931,84,119983,84,120035,84,120087,84,120139,84,120191,84,120243,84,120295,84,120347,84,120399,84,120451,84,932,84,120507,84,120565,84,120623,84,120681,84,120739,84,11430,84,5026,84,42196,84,93962,84,71868,84,66199,84,66225,84,66325,84,119854,117,119906,117,119958,117,120010,117,120062,117,120114,117,120166,117,120218,117,120270,117,120322,117,120374,117,120426,117,120478,117,42911,117,7452,117,43854,117,43858,117,651,117,965,117,120534,117,120592,117,120650,117,120708,117,120766,117,1405,117,66806,117,71896,117,8746,85,8899,85,119828,85,119880,85,119932,85,119984,85,120036,85,120088,85,120140,85,120192,85,120244,85,120296,85,120348,85,120400,85,120452,85,1357,85,4608,85,66766,85,5196,85,42228,85,94018,85,71864,85,8744,118,8897,118,65366,118,8564,118,119855,118,119907,118,119959,118,120011,118,120063,118,120115,118,120167,118,120219,118,120271,118,120323,118,120375,118,120427,118,120479,118,7456,118,957,118,120526,118,120584,118,120642,118,120700,118,120758,118,1141,118,1496,118,71430,118,43945,118,71872,118,119309,86,1639,86,1783,86,8548,86,119829,86,119881,86,119933,86,119985,86,120037,86,120089,86,120141,86,120193,86,120245,86,120297,86,120349,86,120401,86,120453,86,1140,86,11576,86,5081,86,5167,86,42719,86,42214,86,93960,86,71840,86,66845,86,623,119,119856,119,119908,119,119960,119,120012,119,120064,119,120116,119,120168,119,120220,119,120272,119,120324,119,120376,119,120428,119,120480,119,7457,119,1121,119,1309,119,1377,119,71434,119,71438,119,71439,119,43907,119,71919,87,71910,87,119830,87,119882,87,119934,87,119986,87,120038,87,120090,87,120142,87,120194,87,120246,87,120298,87,120350,87,120402,87,120454,87,1308,87,5043,87,5076,87,42218,87,5742,120,10539,120,10540,120,10799,120,65368,120,8569,120,119857,120,119909,120,119961,120,120013,120,120065,120,120117,120,120169,120,120221,120,120273,120,120325,120,120377,120,120429,120,120481,120,5441,120,5501,120,5741,88,9587,88,66338,88,71916,88,65336,88,8553,88,119831,88,119883,88,119935,88,119987,88,120039,88,120091,88,120143,88,120195,88,120247,88,120299,88,120351,88,120403,88,120455,88,42931,88,935,88,120510,88,120568,88,120626,88,120684,88,120742,88,11436,88,11613,88,5815,88,42219,88,66192,88,66228,88,66327,88,66855,88,611,121,7564,121,65369,121,119858,121,119910,121,119962,121,120014,121,120066,121,120118,121,120170,121,120222,121,120274,121,120326,121,120378,121,120430,121,120482,121,655,121,7935,121,43866,121,947,121,8509,121,120516,121,120574,121,120632,121,120690,121,120748,121,1199,121,4327,121,71900,121,65337,89,119832,89,119884,89,119936,89,119988,89,120040,89,120092,89,120144,89,120196,89,120248,89,120300,89,120352,89,120404,89,120456,89,933,89,978,89,120508,89,120566,89,120624,89,120682,89,120740,89,11432,89,1198,89,5033,89,5053,89,42220,89,94019,89,71844,89,66226,89,119859,122,119911,122,119963,122,120015,122,120067,122,120119,122,120171,122,120223,122,120275,122,120327,122,120379,122,120431,122,120483,122,7458,122,43923,122,71876,122,66293,90,71909,90,65338,90,8484,90,8488,90,119833,90,119885,90,119937,90,119989,90,120041,90,120197,90,120249,90,120301,90,120353,90,120405,90,120457,90,918,90,120493,90,120551,90,120609,90,120667,90,120725,90,5059,90,42204,90,71849,90,65282,34,65284,36,65285,37,65286,38,65290,42,65291,43,65294,46,65295,47,65296,48,65297,49,65298,50,65299,51,65300,52,65301,53,65302,54,65303,55,65304,56,65305,57,65308,60,65309,61,65310,62,65312,64,65316,68,65318,70,65319,71,65324,76,65329,81,65330,82,65333,85,65334,86,65335,87,65343,95,65346,98,65348,100,65350,102,65355,107,65357,109,65358,110,65361,113,65362,114,65364,116,65365,117,65367,119,65370,122,65371,123,65373,125,119846,109],"_default":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"cs":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"de":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"es":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"fr":[65374,126,65306,58,65281,33,8216,96,8245,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"it":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ja":[8211,45,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65292,44,65307,59],"ko":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pl":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pt-BR":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"qps-ploc":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ru":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,305,105,921,73,1009,112,215,120,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"tr":[160,32,8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"zh-hans":[65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65288,40,65289,41],"zh-hant":[8211,45,65374,126,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65307,59]}')))}static{this.cache=new r.o5({getCacheKey:JSON.stringify},(e=>{function t(e){const t=new Map;for(let n=0;n!e.startsWith("_")&&e in r));0===s.length&&(s=["_default"]);for(const a of s){i=n(i,t(r[a]))}const o=function(e,t){const n=new Map(e);for(const[r,i]of t)n.set(r,i);return n}(t(r._common),i);return new z(o)}))}static getInstance(e){return z.cache.get(Array.from(e))}static{this._locales=new i.d((()=>Object.keys(z.ambiguousCharacterData.value).filter((e=>!e.startsWith("_")))))}static getLocales(){return z._locales.value}constructor(e){this.confusableDictionary=e}isAmbiguous(e){return this.confusableDictionary.has(e)}getPrimaryConfusable(e){return this.confusableDictionary.get(e)}getConfusableCodePoints(){return new Set(this.confusableDictionary.keys())}}class j{static getRawData(){return JSON.parse("[9,10,11,12,13,32,127,160,173,847,1564,4447,4448,6068,6069,6155,6156,6157,6158,7355,7356,8192,8193,8194,8195,8196,8197,8198,8199,8200,8201,8202,8203,8204,8205,8206,8207,8234,8235,8236,8237,8238,8239,8287,8288,8289,8290,8291,8292,8293,8294,8295,8296,8297,8298,8299,8300,8301,8302,8303,10240,12288,12644,65024,65025,65026,65027,65028,65029,65030,65031,65032,65033,65034,65035,65036,65037,65038,65039,65279,65440,65520,65521,65522,65523,65524,65525,65526,65527,65528,65532,78844,119155,119156,119157,119158,119159,119160,119161,119162,917504,917505,917506,917507,917508,917509,917510,917511,917512,917513,917514,917515,917516,917517,917518,917519,917520,917521,917522,917523,917524,917525,917526,917527,917528,917529,917530,917531,917532,917533,917534,917535,917536,917537,917538,917539,917540,917541,917542,917543,917544,917545,917546,917547,917548,917549,917550,917551,917552,917553,917554,917555,917556,917557,917558,917559,917560,917561,917562,917563,917564,917565,917566,917567,917568,917569,917570,917571,917572,917573,917574,917575,917576,917577,917578,917579,917580,917581,917582,917583,917584,917585,917586,917587,917588,917589,917590,917591,917592,917593,917594,917595,917596,917597,917598,917599,917600,917601,917602,917603,917604,917605,917606,917607,917608,917609,917610,917611,917612,917613,917614,917615,917616,917617,917618,917619,917620,917621,917622,917623,917624,917625,917626,917627,917628,917629,917630,917631,917760,917761,917762,917763,917764,917765,917766,917767,917768,917769,917770,917771,917772,917773,917774,917775,917776,917777,917778,917779,917780,917781,917782,917783,917784,917785,917786,917787,917788,917789,917790,917791,917792,917793,917794,917795,917796,917797,917798,917799,917800,917801,917802,917803,917804,917805,917806,917807,917808,917809,917810,917811,917812,917813,917814,917815,917816,917817,917818,917819,917820,917821,917822,917823,917824,917825,917826,917827,917828,917829,917830,917831,917832,917833,917834,917835,917836,917837,917838,917839,917840,917841,917842,917843,917844,917845,917846,917847,917848,917849,917850,917851,917852,917853,917854,917855,917856,917857,917858,917859,917860,917861,917862,917863,917864,917865,917866,917867,917868,917869,917870,917871,917872,917873,917874,917875,917876,917877,917878,917879,917880,917881,917882,917883,917884,917885,917886,917887,917888,917889,917890,917891,917892,917893,917894,917895,917896,917897,917898,917899,917900,917901,917902,917903,917904,917905,917906,917907,917908,917909,917910,917911,917912,917913,917914,917915,917916,917917,917918,917919,917920,917921,917922,917923,917924,917925,917926,917927,917928,917929,917930,917931,917932,917933,917934,917935,917936,917937,917938,917939,917940,917941,917942,917943,917944,917945,917946,917947,917948,917949,917950,917951,917952,917953,917954,917955,917956,917957,917958,917959,917960,917961,917962,917963,917964,917965,917966,917967,917968,917969,917970,917971,917972,917973,917974,917975,917976,917977,917978,917979,917980,917981,917982,917983,917984,917985,917986,917987,917988,917989,917990,917991,917992,917993,917994,917995,917996,917997,917998,917999]")}static{this._data=void 0}static getData(){return this._data||(this._data=new Set(j.getRawData())),this._data}static isInvisibleCharacter(e){return j.getData().has(e)}static get codePoints(){return j.getData()}}},631:(e,t,n)=>{"use strict";function r(e){return"string"===typeof e}function i(e){return"object"===typeof e&&null!==e&&!Array.isArray(e)&&!(e instanceof RegExp)&&!(e instanceof Date)}function s(e){return"undefined"===typeof e}function o(e){return s(e)||null===e}n.d(t,{Gv:()=>i,Kg:()=>r,b0:()=>s,z:()=>o})},5152:(e,t,n)=>{"use strict";function r(e){return e<0?0:e>255?255:0|e}function i(e){return e<0?0:e>4294967295?4294967295:0|e}n.d(t,{W:()=>r,j:()=>i})},9400:(e,t,n)=>{"use strict";n.d(t,{I:()=>b,r:()=>u});var r=n(8821),i=n(8067);const s=/^\w[\w\d+.-]*$/,o=/^\//,a=/^\/\//;const l="",c="/",h=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/;class u{static isUri(e){return e instanceof u||!!e&&("string"===typeof e.authority&&"string"===typeof e.fragment&&"string"===typeof e.path&&"string"===typeof e.query&&"string"===typeof e.scheme&&"string"===typeof e.fsPath&&"function"===typeof e.with&&"function"===typeof e.toString)}constructor(e,t,n,r,i,h=!1){"object"===typeof e?(this.scheme=e.scheme||l,this.authority=e.authority||l,this.path=e.path||l,this.query=e.query||l,this.fragment=e.fragment||l):(this.scheme=function(e,t){return e||t?e:"file"}(e,h),this.authority=t||l,this.path=function(e,t){switch(e){case"https":case"http":case"file":t?t[0]!==c&&(t=c+t):t=c}return t}(this.scheme,n||l),this.query=r||l,this.fragment=i||l,function(e,t){if(!e.scheme&&t)throw new Error(`[UriError]: Scheme is missing: {scheme: "", authority: "${e.authority}", path: "${e.path}", query: "${e.query}", fragment: "${e.fragment}"}`);if(e.scheme&&!s.test(e.scheme))throw new Error("[UriError]: Scheme contains illegal characters.");if(e.path)if(e.authority){if(!o.test(e.path))throw new Error('[UriError]: If a URI contains an authority component, then the path component must either be empty or begin with a slash ("/") character')}else if(a.test(e.path))throw new Error('[UriError]: If a URI does not contain an authority component, then the path cannot begin with two slash characters ("//")')}(this,h))}get fsPath(){return b(this,!1)}with(e){if(!e)return this;let{scheme:t,authority:n,path:r,query:i,fragment:s}=e;return void 0===t?t=this.scheme:null===t&&(t=l),void 0===n?n=this.authority:null===n&&(n=l),void 0===r?r=this.path:null===r&&(r=l),void 0===i?i=this.query:null===i&&(i=l),void 0===s?s=this.fragment:null===s&&(s=l),t===this.scheme&&n===this.authority&&r===this.path&&i===this.query&&s===this.fragment?this:new g(t,n,r,i,s)}static parse(e,t=!1){const n=h.exec(e);return n?new g(n[2]||l,C(n[4]||l),C(n[5]||l),C(n[7]||l),C(n[9]||l),t):new g(l,l,l,l,l)}static file(e){let t=l;if(i.uF&&(e=e.replace(/\\/g,c)),e[0]===c&&e[1]===c){const n=e.indexOf(c,2);-1===n?(t=e.substring(2),e=c):(t=e.substring(2,n),e=e.substring(n)||c)}return new g("file",t,e,l,l)}static from(e,t){return new g(e.scheme,e.authority,e.path,e.query,e.fragment,t)}static joinPath(e,...t){if(!e.path)throw new Error("[UriError]: cannot call joinPath on URI without path");let n;return n=i.uF&&"file"===e.scheme?u.file(r.IN.join(b(e,!0),...t)).path:r.SA.join(e.path,...t),e.with({path:n})}toString(e=!1){return _(this,e)}toJSON(){return this}static revive(e){if(e){if(e instanceof u)return e;{const t=new g(e);return t._formatted=e.external??null,t._fsPath=e._sep===d?e.fsPath??null:null,t}}return e}}const d=i.uF?1:void 0;class g extends u{constructor(){super(...arguments),this._formatted=null,this._fsPath=null}get fsPath(){return this._fsPath||(this._fsPath=b(this,!1)),this._fsPath}toString(e=!1){return e?_(this,!0):(this._formatted||(this._formatted=_(this,!1)),this._formatted)}toJSON(){const e={$mid:1};return this._fsPath&&(e.fsPath=this._fsPath,e._sep=d),this._formatted&&(e.external=this._formatted),this.path&&(e.path=this.path),this.scheme&&(e.scheme=this.scheme),this.authority&&(e.authority=this.authority),this.query&&(e.query=this.query),this.fragment&&(e.fragment=this.fragment),e}}const f={58:"%3A",47:"%2F",63:"%3F",35:"%23",91:"%5B",93:"%5D",64:"%40",33:"%21",36:"%24",38:"%26",39:"%27",40:"%28",41:"%29",42:"%2A",43:"%2B",44:"%2C",59:"%3B",61:"%3D",32:"%20"};function m(e,t,n){let r,i=-1;for(let s=0;s=97&&o<=122||o>=65&&o<=90||o>=48&&o<=57||45===o||46===o||95===o||126===o||t&&47===o||n&&91===o||n&&93===o||n&&58===o)-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),void 0!==r&&(r+=e.charAt(s));else{void 0===r&&(r=e.substr(0,s));const t=f[o];void 0!==t?(-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),r+=t):-1===i&&(i=s)}}return-1!==i&&(r+=encodeURIComponent(e.substring(i))),void 0!==r?r:e}function p(e){let t;for(let n=0;n1&&"file"===e.scheme?`//${e.authority}${e.path}`:47===e.path.charCodeAt(0)&&(e.path.charCodeAt(1)>=65&&e.path.charCodeAt(1)<=90||e.path.charCodeAt(1)>=97&&e.path.charCodeAt(1)<=122)&&58===e.path.charCodeAt(2)?t?e.path.substr(1):e.path[1].toLowerCase()+e.path.substr(2):e.path,i.uF&&(n=n.replace(/\//g,"\\")),n}function _(e,t){const n=t?p:m;let r="",{scheme:i,authority:s,path:o,query:a,fragment:l}=e;if(i&&(r+=i,r+=":"),(s||"file"===i)&&(r+=c,r+=c),s){let e=s.indexOf("@");if(-1!==e){const t=s.substr(0,e);s=s.substr(e+1),e=t.lastIndexOf(":"),-1===e?r+=n(t,!1,!1):(r+=n(t.substr(0,e),!1,!1),r+=":",r+=n(t.substr(e+1),!1,!0)),r+="@"}s=s.toLowerCase(),e=s.lastIndexOf(":"),-1===e?r+=n(s,!1,!0):(r+=n(s.substr(0,e),!1,!0),r+=s.substr(e))}if(o){if(o.length>=3&&47===o.charCodeAt(0)&&58===o.charCodeAt(2)){const e=o.charCodeAt(1);e>=65&&e<=90&&(o=`/${String.fromCharCode(e+32)}:${o.substr(3)}`)}else if(o.length>=2&&58===o.charCodeAt(1)){const e=o.charCodeAt(0);e>=65&&e<=90&&(o=`${String.fromCharCode(e+32)}:${o.substr(2)}`)}r+=n(o,!0,!1)}return a&&(r+="?",r+=n(a,!1,!1)),l&&(r+="#",r+=t?l:m(l,!1,!1)),r}function k(e){try{return decodeURIComponent(e)}catch{return e.length>3?e.substr(0,3)+k(e.substr(3)):e}}const v=/(%[0-9A-Za-z][0-9A-Za-z])+/g;function C(e){return e.match(v)?e.replace(v,(e=>k(e))):e}},1929:(e,t,n)=>{"use strict";n.r(t),n.d(t,{SimpleWorkerClient:()=>k,SimpleWorkerServer:()=>y,create:()=>L,logOnceWebWorkerWarning:()=>d});var r=n(4383),i=n(1234),s=n(1484),o=n(6456),a=n(8067),l=n(1508);const c="default",h="$initialize";let u=!1;function d(e){a.HZ&&(u||(u=!0,console.warn("Could not create web worker(s). Falling back to loading web worker code in main thread, which might cause UI freezes. Please see https://github.com/microsoft/monaco-editor#faq")),console.warn(e.message))}class g{constructor(e,t,n,r,i){this.vsWorker=e,this.req=t,this.channel=n,this.method=r,this.args=i,this.type=0}}class f{constructor(e,t,n,r){this.vsWorker=e,this.seq=t,this.res=n,this.err=r,this.type=1}}class m{constructor(e,t,n,r,i){this.vsWorker=e,this.req=t,this.channel=n,this.eventName=r,this.arg=i,this.type=2}}class p{constructor(e,t,n){this.vsWorker=e,this.req=t,this.event=n,this.type=3}}class b{constructor(e,t){this.vsWorker=e,this.req=t,this.type=4}}class _{constructor(e){this._workerId=-1,this._handler=e,this._lastSentReq=0,this._pendingReplies=Object.create(null),this._pendingEmitters=new Map,this._pendingEvents=new Map}setWorkerId(e){this._workerId=e}sendMessage(e,t,n){const r=String(++this._lastSentReq);return new Promise(((i,s)=>{this._pendingReplies[r]={resolve:i,reject:s},this._send(new g(this._workerId,r,e,t,n))}))}listen(e,t,n){let r=null;const s=new i.vl({onWillAddFirstListener:()=>{r=String(++this._lastSentReq),this._pendingEmitters.set(r,s),this._send(new m(this._workerId,r,e,t,n))},onDidRemoveLastListener:()=>{this._pendingEmitters.delete(r),this._send(new b(this._workerId,r)),r=null}});return s.event}handleMessage(e){e&&e.vsWorker&&(-1!==this._workerId&&e.vsWorker!==this._workerId||this._handleMessage(e))}createProxyToRemoteChannel(e,t){const n={get:(n,r)=>("string"!==typeof r||n[r]||(C(r)?n[r]=t=>this.listen(e,r,t):v(r)?n[r]=this.listen(e,r,void 0):36===r.charCodeAt(0)&&(n[r]=async(...n)=>(await(t?.()),this.sendMessage(e,r,n)))),n[r])};return new Proxy(Object.create(null),n)}_handleMessage(e){switch(e.type){case 1:return this._handleReplyMessage(e);case 0:return this._handleRequestMessage(e);case 2:return this._handleSubscribeEventMessage(e);case 3:return this._handleEventMessage(e);case 4:return this._handleUnsubscribeEventMessage(e)}}_handleReplyMessage(e){if(!this._pendingReplies[e.seq])return void console.warn("Got reply to unknown seq");const t=this._pendingReplies[e.seq];if(delete this._pendingReplies[e.seq],e.err){let n=e.err;return e.err.$isError&&(n=new Error,n.name=e.err.name,n.message=e.err.message,n.stack=e.err.stack),void t.reject(n)}t.resolve(e.res)}_handleRequestMessage(e){const t=e.req;this._handler.handleMessage(e.channel,e.method,e.args).then((e=>{this._send(new f(this._workerId,t,e,void 0))}),(e=>{e.detail instanceof Error&&(e.detail=(0,r.cU)(e.detail)),this._send(new f(this._workerId,t,void 0,(0,r.cU)(e)))}))}_handleSubscribeEventMessage(e){const t=e.req,n=this._handler.handleEvent(e.channel,e.eventName,e.arg)((e=>{this._send(new p(this._workerId,t,e))}));this._pendingEvents.set(t,n)}_handleEventMessage(e){this._pendingEmitters.has(e.req)?this._pendingEmitters.get(e.req).fire(e.event):console.warn("Got event for unknown req")}_handleUnsubscribeEventMessage(e){this._pendingEvents.has(e.req)?(this._pendingEvents.get(e.req).dispose(),this._pendingEvents.delete(e.req)):console.warn("Got unsubscribe for unknown req")}_send(e){const t=[];if(0===e.type)for(let n=0;n{this._protocol.handleMessage(e)}),(e=>{(0,r.dz)(e)}))),this._protocol=new _({sendMessage:(e,t)=>{this._worker.postMessage(e,t)},handleMessage:(e,t,n)=>this._handleMessage(e,t,n),handleEvent:(e,t,n)=>this._handleEvent(e,t,n)}),this._protocol.setWorkerId(this._worker.getId());let n=null;const i=globalThis.require;"undefined"!==typeof i&&"function"===typeof i.getConfig?n=i.getConfig():"undefined"!==typeof globalThis.requirejs&&(n=globalThis.requirejs.s.contexts._.config),this._onModuleLoaded=this._protocol.sendMessage(c,h,[this._worker.getId(),JSON.parse(JSON.stringify(n)),t.amdModuleId]),this.proxy=this._protocol.createProxyToRemoteChannel(c,(async()=>{await this._onModuleLoaded})),this._onModuleLoaded.catch((e=>{this._onError("Worker failed to load "+t.amdModuleId,e)}))}_handleMessage(e,t,n){const r=this._localChannels.get(e);if(!r)return Promise.reject(new Error(`Missing channel ${e} on main thread`));if("function"!==typeof r[t])return Promise.reject(new Error(`Missing method ${t} on main thread channel ${e}`));try{return Promise.resolve(r[t].apply(r,n))}catch(i){return Promise.reject(i)}}_handleEvent(e,t,n){const r=this._localChannels.get(e);if(!r)throw new Error(`Missing channel ${e} on main thread`);if(C(t)){const i=r[t].call(r,n);if("function"!==typeof i)throw new Error(`Missing dynamic event ${t} on main thread channel ${e}.`);return i}if(v(t)){const n=r[t];if("function"!==typeof n)throw new Error(`Missing event ${t} on main thread channel ${e}.`);return n}throw new Error(`Malformed event name ${t}`)}setChannel(e,t){this._localChannels.set(e,t)}_onError(e,t){console.error(e),console.info(t)}}function v(e){return"o"===e[0]&&"n"===e[1]&&l.Wv(e.charCodeAt(2))}function C(e){return/^onDynamic/.test(e)&&l.Wv(e.charCodeAt(9))}class y{constructor(e,t){this._localChannels=new Map,this._remoteChannels=new Map,this._requestHandlerFactory=t,this._requestHandler=null,this._protocol=new _({sendMessage:(t,n)=>{e(t,n)},handleMessage:(e,t,n)=>this._handleMessage(e,t,n),handleEvent:(e,t,n)=>this._handleEvent(e,t,n)})}onmessage(e){this._protocol.handleMessage(e)}_handleMessage(e,t,n){if(e===c&&t===h)return this.initialize(n[0],n[1],n[2]);const r=e===c?this._requestHandler:this._localChannels.get(e);if(!r)return Promise.reject(new Error(`Missing channel ${e} on worker thread`));if("function"!==typeof r[t])return Promise.reject(new Error(`Missing method ${t} on worker thread channel ${e}`));try{return Promise.resolve(r[t].apply(r,n))}catch(i){return Promise.reject(i)}}_handleEvent(e,t,n){const r=e===c?this._requestHandler:this._localChannels.get(e);if(!r)throw new Error(`Missing channel ${e} on worker thread`);if(C(t)){const e=r[t].call(r,n);if("function"!==typeof e)throw new Error(`Missing dynamic event ${t} on request handler.`);return e}if(v(t)){const e=r[t];if("function"!==typeof e)throw new Error(`Missing event ${t} on request handler.`);return e}throw new Error(`Malformed event name ${t}`)}getChannel(e){if(!this._remoteChannels.has(e)){const t=this._protocol.createProxyToRemoteChannel(e);this._remoteChannels.set(e,t)}return this._remoteChannels.get(e)}async initialize(e,t,r){if(this._protocol.setWorkerId(e),!this._requestHandlerFactory){t&&("undefined"!==typeof t.baseUrl&&delete t.baseUrl,"undefined"!==typeof t.paths&&"undefined"!==typeof t.paths.vs&&delete t.paths.vs,"undefined"!==typeof t.trustedTypesPolicy&&delete t.trustedTypesPolicy,t.catchError=!0,globalThis.require.config(t));{const e=o.zl.asBrowserUri(`${r}.js`).toString(!0);return n(5890)(`${e}`).then((e=>{if(this._requestHandler=e.create(this),!this._requestHandler)throw new Error("No RequestHandler!")}))}}this._requestHandler=this._requestHandlerFactory(this)}}function L(e){return new y(e,null)}},534:(e,t,n)=>{"use strict";n.d(t,{V:()=>i});var r=n(5152);class i{constructor(e){const t=(0,r.W)(e);this._defaultValue=t,this._asciiMap=i._createAsciiMap(t),this._map=new Map}static _createAsciiMap(e){const t=new Uint8Array(256);return t.fill(e),t}set(e,t){const n=(0,r.W)(t);e>=0&&e<256?this._asciiMap[e]=n:this._map.set(e,n)}get(e){return e>=0&&e<256?this._asciiMap[e]:this._map.get(e)||this._defaultValue}clear(){this._asciiMap.fill(this._defaultValue),this._map.clear()}}},7119:(e,t,n)=>{"use strict";n.d(t,{AQ:()=>b,aZ:()=>p,l5:()=>C,lQ:()=>k,s7:()=>w,sH:()=>y,sN:()=>_,ss:()=>v,yI:()=>m,zp:()=>L});var r=n(8209),i=n(7661),s=n(5845),o=n(5724);const a=(0,s.x1A)("editor.lineHighlightBackground",null,r.kg("lineHighlight","Background color for the highlight of line at the cursor position.")),l=((0,s.x1A)("editor.lineHighlightBorder",{dark:"#282828",light:"#eeeeee",hcDark:"#f38518",hcLight:s.b1q},r.kg("lineHighlightBorderBox","Background color for the border around the line at the cursor position.")),(0,s.x1A)("editor.rangeHighlightBackground",{dark:"#ffffff0b",light:"#fdff0033",hcDark:null,hcLight:null},r.kg("rangeHighlight","Background color of highlighted ranges, like by quick open and find features. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1A)("editor.rangeHighlightBorder",{dark:null,light:null,hcDark:s.buw,hcLight:s.buw},r.kg("rangeHighlightBorder","Background color of the border around highlighted ranges.")),(0,s.x1A)("editor.symbolHighlightBackground",{dark:s.Ubg,light:s.Ubg,hcDark:null,hcLight:null},r.kg("symbolHighlight","Background color of highlighted symbol, like for go to definition or go next/previous symbol. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1A)("editor.symbolHighlightBorder",{dark:null,light:null,hcDark:s.buw,hcLight:s.buw},r.kg("symbolHighlightBorder","Background color of the border around highlighted symbols.")),(0,s.x1A)("editorCursor.foreground",{dark:"#AEAFAD",light:i.Q1.black,hcDark:i.Q1.white,hcLight:"#0F4A85"},r.kg("caret","Color of the editor cursor."))),c=(0,s.x1A)("editorCursor.background",null,r.kg("editorCursorBackground","The background color of the editor cursor. Allows customizing the color of a character overlapped by a block cursor.")),h=((0,s.x1A)("editorMultiCursor.primary.foreground",l,r.kg("editorMultiCursorPrimaryForeground","Color of the primary editor cursor when multiple cursors are present.")),(0,s.x1A)("editorMultiCursor.primary.background",c,r.kg("editorMultiCursorPrimaryBackground","The background color of the primary editor cursor when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),(0,s.x1A)("editorMultiCursor.secondary.foreground",l,r.kg("editorMultiCursorSecondaryForeground","Color of secondary editor cursors when multiple cursors are present.")),(0,s.x1A)("editorMultiCursor.secondary.background",c,r.kg("editorMultiCursorSecondaryBackground","The background color of secondary editor cursors when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),(0,s.x1A)("editorWhitespace.foreground",{dark:"#e3e4e229",light:"#33333333",hcDark:"#e3e4e229",hcLight:"#CCCCCC"},r.kg("editorWhitespaces","Color of whitespace characters in the editor."))),u=((0,s.x1A)("editorLineNumber.foreground",{dark:"#858585",light:"#237893",hcDark:i.Q1.white,hcLight:"#292929"},r.kg("editorLineNumbers","Color of editor line numbers.")),(0,s.x1A)("editorIndentGuide.background",h,r.kg("editorIndentGuides","Color of the editor indentation guides."),!1,r.kg("deprecatedEditorIndentGuides","'editorIndentGuide.background' is deprecated. Use 'editorIndentGuide.background1' instead."))),d=(0,s.x1A)("editorIndentGuide.activeBackground",h,r.kg("editorActiveIndentGuide","Color of the active editor indentation guides."),!1,r.kg("deprecatedEditorActiveIndentGuide","'editorIndentGuide.activeBackground' is deprecated. Use 'editorIndentGuide.activeBackground1' instead.")),g=((0,s.x1A)("editorIndentGuide.background1",u,r.kg("editorIndentGuides1","Color of the editor indentation guides (1).")),(0,s.x1A)("editorIndentGuide.background2","#00000000",r.kg("editorIndentGuides2","Color of the editor indentation guides (2).")),(0,s.x1A)("editorIndentGuide.background3","#00000000",r.kg("editorIndentGuides3","Color of the editor indentation guides (3).")),(0,s.x1A)("editorIndentGuide.background4","#00000000",r.kg("editorIndentGuides4","Color of the editor indentation guides (4).")),(0,s.x1A)("editorIndentGuide.background5","#00000000",r.kg("editorIndentGuides5","Color of the editor indentation guides (5).")),(0,s.x1A)("editorIndentGuide.background6","#00000000",r.kg("editorIndentGuides6","Color of the editor indentation guides (6).")),(0,s.x1A)("editorIndentGuide.activeBackground1",d,r.kg("editorActiveIndentGuide1","Color of the active editor indentation guides (1).")),(0,s.x1A)("editorIndentGuide.activeBackground2","#00000000",r.kg("editorActiveIndentGuide2","Color of the active editor indentation guides (2).")),(0,s.x1A)("editorIndentGuide.activeBackground3","#00000000",r.kg("editorActiveIndentGuide3","Color of the active editor indentation guides (3).")),(0,s.x1A)("editorIndentGuide.activeBackground4","#00000000",r.kg("editorActiveIndentGuide4","Color of the active editor indentation guides (4).")),(0,s.x1A)("editorIndentGuide.activeBackground5","#00000000",r.kg("editorActiveIndentGuide5","Color of the active editor indentation guides (5).")),(0,s.x1A)("editorIndentGuide.activeBackground6","#00000000",r.kg("editorActiveIndentGuide6","Color of the active editor indentation guides (6).")),(0,s.x1A)("editorActiveLineNumber.foreground",{dark:"#c6c6c6",light:"#0B216F",hcDark:s.buw,hcLight:s.buw},r.kg("editorActiveLineNumber","Color of editor active line number"),!1,r.kg("deprecatedEditorActiveLineNumber","Id is deprecated. Use 'editorLineNumber.activeForeground' instead."))),f=((0,s.x1A)("editorLineNumber.activeForeground",g,r.kg("editorActiveLineNumber","Color of editor active line number")),(0,s.x1A)("editorLineNumber.dimmedForeground",null,r.kg("editorDimmedLineNumber","Color of the final editor line when editor.renderFinalNewline is set to dimmed.")),(0,s.x1A)("editorRuler.foreground",{dark:"#5A5A5A",light:i.Q1.lightgrey,hcDark:i.Q1.white,hcLight:"#292929"},r.kg("editorRuler","Color of the editor rulers.")),(0,s.x1A)("editorCodeLens.foreground",{dark:"#999999",light:"#919191",hcDark:"#999999",hcLight:"#292929"},r.kg("editorCodeLensForeground","Foreground color of editor CodeLens")),(0,s.x1A)("editorBracketMatch.background",{dark:"#0064001a",light:"#0064001a",hcDark:"#0064001a",hcLight:"#0000"},r.kg("editorBracketMatchBackground","Background color behind matching brackets")),(0,s.x1A)("editorBracketMatch.border",{dark:"#888",light:"#B9B9B9",hcDark:s.b1q,hcLight:s.b1q},r.kg("editorBracketMatchBorder","Color for matching brackets boxes")),(0,s.x1A)("editorOverviewRuler.border",{dark:"#7f7f7f4d",light:"#7f7f7f4d",hcDark:"#7f7f7f4d",hcLight:"#666666"},r.kg("editorOverviewRulerBorder","Color of the overview ruler border.")),(0,s.x1A)("editorOverviewRuler.background",null,r.kg("editorOverviewRulerBackground","Background color of the editor overview ruler.")),(0,s.x1A)("editorGutter.background",s.YtV,r.kg("editorGutter","Background color of the editor gutter. The gutter contains the glyph margins and the line numbers.")),(0,s.x1A)("editorUnnecessaryCode.border",{dark:null,light:null,hcDark:i.Q1.fromHex("#fff").transparent(.8),hcLight:s.b1q},r.kg("unnecessaryCodeBorder","Border color of unnecessary (unused) source code in the editor.")),(0,s.x1A)("editorUnnecessaryCode.opacity",{dark:i.Q1.fromHex("#000a"),light:i.Q1.fromHex("#0007"),hcDark:null,hcLight:null},r.kg("unnecessaryCodeOpacity","Opacity of unnecessary (unused) source code in the editor. For example, \"#000000c0\" will render the code with 75% opacity. For high contrast themes, use the 'editorUnnecessaryCode.border' theme color to underline unnecessary code instead of fading it out.")),(0,s.x1A)("editorGhostText.border",{dark:null,light:null,hcDark:i.Q1.fromHex("#fff").transparent(.8),hcLight:i.Q1.fromHex("#292929").transparent(.8)},r.kg("editorGhostTextBorder","Border color of ghost text in the editor.")),(0,s.x1A)("editorGhostText.foreground",{dark:i.Q1.fromHex("#ffffff56"),light:i.Q1.fromHex("#0007"),hcDark:null,hcLight:null},r.kg("editorGhostTextForeground","Foreground color of the ghost text in the editor.")),(0,s.x1A)("editorGhostText.background",null,r.kg("editorGhostTextBackground","Background color of the ghost text in the editor.")),new i.Q1(new i.bU(0,122,204,.6))),m=((0,s.x1A)("editorOverviewRuler.rangeHighlightForeground",f,r.kg("overviewRulerRangeHighlight","Overview ruler marker color for range highlights. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1A)("editorOverviewRuler.errorForeground",{dark:new i.Q1(new i.bU(255,18,18,.7)),light:new i.Q1(new i.bU(255,18,18,.7)),hcDark:new i.Q1(new i.bU(255,50,50,1)),hcLight:"#B5200D"},r.kg("overviewRuleError","Overview ruler marker color for errors."))),p=(0,s.x1A)("editorOverviewRuler.warningForeground",{dark:s.Hng,light:s.Hng,hcDark:s.Stt,hcLight:s.Stt},r.kg("overviewRuleWarning","Overview ruler marker color for warnings.")),b=(0,s.x1A)("editorOverviewRuler.infoForeground",{dark:s.pOz,light:s.pOz,hcDark:s.IIb,hcLight:s.IIb},r.kg("overviewRuleInfo","Overview ruler marker color for infos.")),_=(0,s.x1A)("editorBracketHighlight.foreground1",{dark:"#FFD700",light:"#0431FAFF",hcDark:"#FFD700",hcLight:"#0431FAFF"},r.kg("editorBracketHighlightForeground1","Foreground color of brackets (1). Requires enabling bracket pair colorization.")),k=(0,s.x1A)("editorBracketHighlight.foreground2",{dark:"#DA70D6",light:"#319331FF",hcDark:"#DA70D6",hcLight:"#319331FF"},r.kg("editorBracketHighlightForeground2","Foreground color of brackets (2). Requires enabling bracket pair colorization.")),v=(0,s.x1A)("editorBracketHighlight.foreground3",{dark:"#179FFF",light:"#7B3814FF",hcDark:"#87CEFA",hcLight:"#7B3814FF"},r.kg("editorBracketHighlightForeground3","Foreground color of brackets (3). Requires enabling bracket pair colorization.")),C=(0,s.x1A)("editorBracketHighlight.foreground4","#00000000",r.kg("editorBracketHighlightForeground4","Foreground color of brackets (4). Requires enabling bracket pair colorization.")),y=(0,s.x1A)("editorBracketHighlight.foreground5","#00000000",r.kg("editorBracketHighlightForeground5","Foreground color of brackets (5). Requires enabling bracket pair colorization.")),L=(0,s.x1A)("editorBracketHighlight.foreground6","#00000000",r.kg("editorBracketHighlightForeground6","Foreground color of brackets (6). Requires enabling bracket pair colorization.")),w=(0,s.x1A)("editorBracketHighlight.unexpectedBracket.foreground",{dark:new i.Q1(new i.bU(255,18,18,.8)),light:new i.Q1(new i.bU(255,18,18,.8)),hcDark:"new Color(new RGBA(255, 50, 50, 1))",hcLight:"#B5200D"},r.kg("editorBracketHighlightUnexpectedBracketForeground","Foreground color of unexpected brackets."));(0,s.x1A)("editorBracketPairGuide.background1","#00000000",r.kg("editorBracketPairGuide.background1","Background color of inactive bracket pair guides (1). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background2","#00000000",r.kg("editorBracketPairGuide.background2","Background color of inactive bracket pair guides (2). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background3","#00000000",r.kg("editorBracketPairGuide.background3","Background color of inactive bracket pair guides (3). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background4","#00000000",r.kg("editorBracketPairGuide.background4","Background color of inactive bracket pair guides (4). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background5","#00000000",r.kg("editorBracketPairGuide.background5","Background color of inactive bracket pair guides (5). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background6","#00000000",r.kg("editorBracketPairGuide.background6","Background color of inactive bracket pair guides (6). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground1","#00000000",r.kg("editorBracketPairGuide.activeBackground1","Background color of active bracket pair guides (1). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground2","#00000000",r.kg("editorBracketPairGuide.activeBackground2","Background color of active bracket pair guides (2). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground3","#00000000",r.kg("editorBracketPairGuide.activeBackground3","Background color of active bracket pair guides (3). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground4","#00000000",r.kg("editorBracketPairGuide.activeBackground4","Background color of active bracket pair guides (4). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground5","#00000000",r.kg("editorBracketPairGuide.activeBackground5","Background color of active bracket pair guides (5). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground6","#00000000",r.kg("editorBracketPairGuide.activeBackground6","Background color of active bracket pair guides (6). Requires enabling bracket pair guides.")),(0,s.x1A)("editorUnicodeHighlight.border",s.Hng,r.kg("editorUnicodeHighlight.border","Border color used to highlight unicode characters.")),(0,s.x1A)("editorUnicodeHighlight.background",s.whs,r.kg("editorUnicodeHighlight.background","Background color used to highlight unicode characters."));(0,o.zy)(((e,t)=>{const n=e.getColor(s.YtV),r=e.getColor(a),i=r&&!r.isTransparent()?r:n;i&&t.addRule(`.monaco-editor .inputarea.ime-input { background-color: ${i}; }`)}))},4454:(e,t,n)=>{"use strict";function r(e){let t=0,n=0,r=0,i=0;for(let s=0,o=e.length;sr})},6571:(e,t,n)=>{"use strict";n.d(t,{M:()=>a,S:()=>l});var r=n(4383),i=n(4444),s=n(6677),o=n(6041);class a{static fromRangeInclusive(e){return new a(e.startLineNumber,e.endLineNumber+1)}static joinMany(e){if(0===e.length)return[];let t=new l(e[0].slice());for(let n=1;nt)throw new r.D7(`startLineNumber ${e} cannot be after endLineNumberExclusive ${t}`);this.startLineNumber=e,this.endLineNumberExclusive=t}contains(e){return this.startLineNumber<=e&&et.endLineNumberExclusive>=e.startLineNumber)),n=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===n)this._normalizedRanges.splice(t,0,e);else if(t===n-1){const n=this._normalizedRanges[t];this._normalizedRanges[t]=n.join(e)}else{const r=this._normalizedRanges[t].join(this._normalizedRanges[n-1]).join(e);this._normalizedRanges.splice(t,n-t,r)}}contains(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumber<=e));return!!t&&t.endLineNumberExclusive>e}intersects(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumbere.startLineNumber}getUnion(e){if(0===this._normalizedRanges.length)return e;if(0===e._normalizedRanges.length)return this;const t=[];let n=0,r=0,i=null;for(;n=s.startLineNumber?i=new a(i.startLineNumber,Math.max(i.endLineNumberExclusive,s.endLineNumberExclusive)):(t.push(i),i=s)}return null!==i&&t.push(i),new l(t)}subtractFrom(e){const t=(0,o.hw)(this._normalizedRanges,(t=>t.endLineNumberExclusive>=e.startLineNumber)),n=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===n)return new l([e]);const r=[];let i=e.startLineNumber;for(let s=t;si&&r.push(new a(i,e.startLineNumber)),i=e.endLineNumberExclusive}return ie.toString())).join(", ")}getIntersection(e){const t=[];let n=0,r=0;for(;nt.delta(e))))}}},4444:(e,t,n)=>{"use strict";n.d(t,{L:()=>i});var r=n(4383);class i{static addRange(e,t){let n=0;for(;nt))return new i(e,t)}static ofLength(e){return new i(0,e)}static ofStartAndLength(e,t){return new i(e,e+t)}constructor(e,t){if(this.start=e,this.endExclusive=t,e>t)throw new r.D7(`Invalid range: ${this.toString()}`)}get isEmpty(){return this.start===this.endExclusive}delta(e){return new i(this.start+e,this.endExclusive+e)}deltaStart(e){return new i(this.start+e,this.endExclusive)}deltaEnd(e){return new i(this.start,this.endExclusive+e)}get length(){return this.endExclusive-this.start}toString(){return`[${this.start}, ${this.endExclusive})`}contains(e){return this.start<=e&&e=e.endExclusive}slice(e){return e.slice(this.start,this.endExclusive)}substring(e){return e.substring(this.start,this.endExclusive)}clip(e){if(this.isEmpty)throw new r.D7(`Invalid clipping range: ${this.toString()}`);return Math.max(this.start,Math.min(this.endExclusive-1,e))}clipCyclic(e){if(this.isEmpty)throw new r.D7(`Invalid clipping range: ${this.toString()}`);return e=this.endExclusive?this.start+(e-this.start)%this.length:e}forEach(e){for(let t=this.start;t{"use strict";n.d(t,{y:()=>r});class r{constructor(e,t){this.lineNumber=e,this.column=t}with(e=this.lineNumber,t=this.column){return e===this.lineNumber&&t===this.column?this:new r(e,t)}delta(e=0,t=0){return this.with(this.lineNumber+e,this.column+t)}equals(e){return r.equals(this,e)}static equals(e,t){return!e&&!t||!!e&&!!t&&e.lineNumber===t.lineNumber&&e.column===t.column}isBefore(e){return r.isBefore(this,e)}static isBefore(e,t){return e.lineNumber{"use strict";n.d(t,{Q:()=>i});var r=n(3069);class i{constructor(e,t,n,r){e>n||e===n&&t>r?(this.startLineNumber=n,this.startColumn=r,this.endLineNumber=e,this.endColumn=t):(this.startLineNumber=e,this.startColumn=t,this.endLineNumber=n,this.endColumn=r)}isEmpty(){return i.isEmpty(this)}static isEmpty(e){return e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn}containsPosition(e){return i.containsPosition(this,e)}static containsPosition(e,t){return!(t.lineNumbere.endLineNumber)&&(!(t.lineNumber===e.startLineNumber&&t.columne.endColumn))}static strictContainsPosition(e,t){return!(t.lineNumbere.endLineNumber)&&(!(t.lineNumber===e.startLineNumber&&t.column<=e.startColumn)&&!(t.lineNumber===e.endLineNumber&&t.column>=e.endColumn))}containsRange(e){return i.containsRange(this,e)}static containsRange(e,t){return!(t.startLineNumbere.endLineNumber||t.endLineNumber>e.endLineNumber)&&(!(t.startLineNumber===e.startLineNumber&&t.startColumne.endColumn)))}strictContainsRange(e){return i.strictContainsRange(this,e)}static strictContainsRange(e,t){return!(t.startLineNumbere.endLineNumber||t.endLineNumber>e.endLineNumber)&&(!(t.startLineNumber===e.startLineNumber&&t.startColumn<=e.startColumn)&&!(t.endLineNumber===e.endLineNumber&&t.endColumn>=e.endColumn)))}plusRange(e){return i.plusRange(this,e)}static plusRange(e,t){let n,r,s,o;return t.startLineNumbere.endLineNumber?(s=t.endLineNumber,o=t.endColumn):t.endLineNumber===e.endLineNumber?(s=t.endLineNumber,o=Math.max(t.endColumn,e.endColumn)):(s=e.endLineNumber,o=e.endColumn),new i(n,r,s,o)}intersectRanges(e){return i.intersectRanges(this,e)}static intersectRanges(e,t){let n=e.startLineNumber,r=e.startColumn,s=e.endLineNumber,o=e.endColumn;const a=t.startLineNumber,l=t.startColumn,c=t.endLineNumber,h=t.endColumn;return nc?(s=c,o=h):s===c&&(o=Math.min(o,h)),n>s||n===s&&r>o?null:new i(n,r,s,o)}equalsRange(e){return i.equalsRange(this,e)}static equalsRange(e,t){return!e&&!t||!!e&&!!t&&e.startLineNumber===t.startLineNumber&&e.startColumn===t.startColumn&&e.endLineNumber===t.endLineNumber&&e.endColumn===t.endColumn}getEndPosition(){return i.getEndPosition(this)}static getEndPosition(e){return new r.y(e.endLineNumber,e.endColumn)}getStartPosition(){return i.getStartPosition(this)}static getStartPosition(e){return new r.y(e.startLineNumber,e.startColumn)}toString(){return"["+this.startLineNumber+","+this.startColumn+" -> "+this.endLineNumber+","+this.endColumn+"]"}setEndPosition(e,t){return new i(this.startLineNumber,this.startColumn,e,t)}setStartPosition(e,t){return new i(e,t,this.endLineNumber,this.endColumn)}collapseToStart(){return i.collapseToStart(this)}static collapseToStart(e){return new i(e.startLineNumber,e.startColumn,e.startLineNumber,e.startColumn)}collapseToEnd(){return i.collapseToEnd(this)}static collapseToEnd(e){return new i(e.endLineNumber,e.endColumn,e.endLineNumber,e.endColumn)}delta(e){return new i(this.startLineNumber+e,this.startColumn,this.endLineNumber+e,this.endColumn)}static fromPositions(e,t=e){return new i(e.lineNumber,e.column,t.lineNumber,t.column)}static lift(e){return e?new i(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):null}static isIRange(e){return e&&"number"===typeof e.startLineNumber&&"number"===typeof e.startColumn&&"number"===typeof e.endLineNumber&&"number"===typeof e.endColumn}static areIntersectingOrTouching(e,t){return!(e.endLineNumbere.startLineNumber}toJSON(){return this}}},5326:(e,t,n)=>{"use strict";n.d(t,{L:()=>s});var r=n(3069),i=n(6677);class s extends i.Q{constructor(e,t,n,r){super(e,t,n,r),this.selectionStartLineNumber=e,this.selectionStartColumn=t,this.positionLineNumber=n,this.positionColumn=r}toString(){return"["+this.selectionStartLineNumber+","+this.selectionStartColumn+" -> "+this.positionLineNumber+","+this.positionColumn+"]"}equalsSelection(e){return s.selectionsEqual(this,e)}static selectionsEqual(e,t){return e.selectionStartLineNumber===t.selectionStartLineNumber&&e.selectionStartColumn===t.selectionStartColumn&&e.positionLineNumber===t.positionLineNumber&&e.positionColumn===t.positionColumn}getDirection(){return this.selectionStartLineNumber===this.startLineNumber&&this.selectionStartColumn===this.startColumn?0:1}setEndPosition(e,t){return 0===this.getDirection()?new s(this.startLineNumber,this.startColumn,e,t):new s(e,t,this.startLineNumber,this.startColumn)}getPosition(){return new r.y(this.positionLineNumber,this.positionColumn)}getSelectionStart(){return new r.y(this.selectionStartLineNumber,this.selectionStartColumn)}setStartPosition(e,t){return 0===this.getDirection()?new s(e,t,this.endLineNumber,this.endColumn):new s(this.endLineNumber,this.endColumn,e,t)}static fromPositions(e,t=e){return new s(e.lineNumber,e.column,t.lineNumber,t.column)}static fromRange(e,t){return 0===t?new s(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):new s(e.endLineNumber,e.endColumn,e.startLineNumber,e.startColumn)}static liftSelection(e){return new s(e.selectionStartLineNumber,e.selectionStartColumn,e.positionLineNumber,e.positionColumn)}static selectionsArrEqual(e,t){if(e&&!t||!e&&t)return!1;if(!e&&!t)return!0;if(e.length!==t.length)return!1;for(let n=0,r=e.length;n{"use strict";n.d(t,{W:()=>s});var r=n(3069),i=n(6677);class s{static{this.zero=new s(0,0)}static betweenPositions(e,t){return e.lineNumber===t.lineNumber?new s(0,t.column-e.column):new s(t.lineNumber-e.lineNumber,t.column-1)}static ofRange(e){return s.betweenPositions(e.getStartPosition(),e.getEndPosition())}static ofText(e){let t=0,n=0;for(const r of e)"\n"===r?(t++,n=0):n++;return new s(t,n)}constructor(e,t){this.lineCount=e,this.columnCount=t}isGreaterThanOrEqualTo(e){return this.lineCount!==e.lineCount?this.lineCount>e.lineCount:this.columnCount>=e.columnCount}createRange(e){return 0===this.lineCount?new i.Q(e.lineNumber,e.column,e.lineNumber,e.column+this.columnCount):new i.Q(e.lineNumber,e.column,e.lineNumber+this.lineCount,this.columnCount+1)}addToPosition(e){return 0===this.lineCount?new r.y(e.lineNumber,e.column+this.columnCount):new r.y(e.lineNumber+this.lineCount,this.columnCount+1)}toString(){return`${this.lineCount},${this.columnCount}`}}},6486:(e,t,n)=>{"use strict";n.d(t,{Io:()=>o,Ld:()=>s,Th:()=>l});var r=n(2522),i=n(8925);const s=function(e=""){let t="(-?\\d*\\.\\d\\w*)|([^";for(const n of"`~!@#$%^&*()-=+[{]}\\|;:'\",.<>/?")e.indexOf(n)>=0||(t+="\\"+n);return t+="\\s]+)",new RegExp(t,"g")}();function o(e){let t=s;if(e&&e instanceof RegExp)if(e.global)t=e;else{let n="g";e.ignoreCase&&(n+="i"),e.multiline&&(n+="m"),e.unicode&&(n+="u"),t=new RegExp(e.source,n)}return t.lastIndex=0,t}const a=new i.w;function l(e,t,n,i,s){if(t=o(t),s||(s=r.f.first(a)),n.length>s.maxLen){let r=e-s.maxLen/2;return r<0?r=0:i+=r,l(e,t,n=n.substring(r,e+s.maxLen/2),i,s)}const h=Date.now(),u=e-1-i;let d=-1,g=null;for(let r=1;!(Date.now()-h>=s.timeBudget);r++){const e=u-s.windowSize*r;t.lastIndex=Math.max(0,e);const i=c(t,n,u,d);if(!i&&g)break;if(g=i,e<=0)break;d=e}if(g){const e={word:g[0],startColumn:i+1+g.index,endColumn:i+1+g.index+g[0].length};return t.lastIndex=0,e}return null}function c(e,t,n,r){let i;for(;i=e.exec(t);){const t=i.index||0;if(t<=n&&e.lastIndex>=n)return i;if(r>0&&t>r)return null}return null}a.unshift({maxLen:1e3,windowSize:15,timeBudget:150})},5982:(e,t,n)=>{"use strict";n.d(t,{x:()=>r});class r{static getLanguageId(e){return(255&e)>>>0}static getTokenType(e){return(768&e)>>>8}static containsBalancedBrackets(e){return 0!==(1024&e)}static getFontStyle(e){return(30720&e)>>>11}static getForeground(e){return(16744448&e)>>>15}static getBackground(e){return(4278190080&e)>>>24}static getClassNameFromMetadata(e){let t="mtk"+this.getForeground(e);const n=this.getFontStyle(e);return 1&n&&(t+=" mtki"),2&n&&(t+=" mtkb"),4&n&&(t+=" mtku"),8&n&&(t+=" mtks"),t}static getInlineStyleFromMetadata(e,t){const n=this.getForeground(e),r=this.getFontStyle(e);let i=`color: ${t[n]};`;1&r&&(i+="font-style: italic;"),2&r&&(i+="font-weight: bold;");let s="";return 4&r&&(s+=" underline"),8&r&&(s+=" line-through"),s&&(i+=`text-decoration:${s};`),i}static getPresentationFromMetadata(e){const t=this.getForeground(e),n=this.getFontStyle(e);return{foreground:t,italic:Boolean(1&n),bold:Boolean(2&n),underline:Boolean(4&n),strikethrough:Boolean(8&n)}}}},2083:(e,t,n)=>{"use strict";n.d(t,{rY:()=>p,ou:()=>m,dG:()=>L,OB:()=>w});var r=n(9493),i=(n(9400),n(1234)),s=n(1484);class o{constructor(){this._tokenizationSupports=new Map,this._factories=new Map,this._onDidChange=new i.vl,this.onDidChange=this._onDidChange.event,this._colorMap=null}handleChange(e){this._onDidChange.fire({changedLanguages:e,changedColorMap:!1})}register(e,t){return this._tokenizationSupports.set(e,t),this.handleChange([e]),(0,s.s)((()=>{this._tokenizationSupports.get(e)===t&&(this._tokenizationSupports.delete(e),this.handleChange([e]))}))}get(e){return this._tokenizationSupports.get(e)||null}registerFactory(e,t){this._factories.get(e)?.dispose();const n=new a(this,e,t);return this._factories.set(e,n),(0,s.s)((()=>{const t=this._factories.get(e);t&&t===n&&(this._factories.delete(e),t.dispose())}))}async getOrCreate(e){const t=this.get(e);if(t)return t;const n=this._factories.get(e);return!n||n.isResolved?null:(await n.resolve(),this.get(e))}isResolved(e){if(this.get(e))return!0;const t=this._factories.get(e);return!(t&&!t.isResolved)}setColorMap(e){this._colorMap=e,this._onDidChange.fire({changedLanguages:Array.from(this._tokenizationSupports.keys()),changedColorMap:!0})}getColorMap(){return this._colorMap}getDefaultBackground(){return this._colorMap&&this._colorMap.length>2?this._colorMap[2]:null}}class a extends s.jG{get isResolved(){return this._isResolved}constructor(e,t,n){super(),this._registry=e,this._languageId=t,this._factory=n,this._isDisposed=!1,this._resolvePromise=null,this._isResolved=!1}dispose(){this._isDisposed=!0,super.dispose()}async resolve(){return this._resolvePromise||(this._resolvePromise=this._create()),this._resolvePromise}async _create(){const e=await this._factory.tokenizationSupport;this._isResolved=!0,e&&!this._isDisposed&&this._register(this._registry.register(this._languageId,e))}}var l,c,h,u,d,g,f=n(8209);class m{constructor(e,t,n){this.offset=e,this.type=t,this.language=n,this._tokenBrand=void 0}toString(){return"("+this.offset+", "+this.type+")"}}class p{constructor(e,t){this.tokens=e,this.endState=t,this._encodedTokenizationResultBrand=void 0}}!function(e){e[e.Increase=0]="Increase",e[e.Decrease=1]="Decrease"}(l||(l={})),function(e){const t=new Map;t.set(0,r.W.symbolMethod),t.set(1,r.W.symbolFunction),t.set(2,r.W.symbolConstructor),t.set(3,r.W.symbolField),t.set(4,r.W.symbolVariable),t.set(5,r.W.symbolClass),t.set(6,r.W.symbolStruct),t.set(7,r.W.symbolInterface),t.set(8,r.W.symbolModule),t.set(9,r.W.symbolProperty),t.set(10,r.W.symbolEvent),t.set(11,r.W.symbolOperator),t.set(12,r.W.symbolUnit),t.set(13,r.W.symbolValue),t.set(15,r.W.symbolEnum),t.set(14,r.W.symbolConstant),t.set(15,r.W.symbolEnum),t.set(16,r.W.symbolEnumMember),t.set(17,r.W.symbolKeyword),t.set(27,r.W.symbolSnippet),t.set(18,r.W.symbolText),t.set(19,r.W.symbolColor),t.set(20,r.W.symbolFile),t.set(21,r.W.symbolReference),t.set(22,r.W.symbolCustomColor),t.set(23,r.W.symbolFolder),t.set(24,r.W.symbolTypeParameter),t.set(25,r.W.account),t.set(26,r.W.issues),e.toIcon=function(e){let n=t.get(e);return n||(console.info("No codicon found for CompletionItemKind "+e),n=r.W.symbolProperty),n};const n=new Map;n.set("method",0),n.set("function",1),n.set("constructor",2),n.set("field",3),n.set("variable",4),n.set("class",5),n.set("struct",6),n.set("interface",7),n.set("module",8),n.set("property",9),n.set("event",10),n.set("operator",11),n.set("unit",12),n.set("value",13),n.set("constant",14),n.set("enum",15),n.set("enum-member",16),n.set("enumMember",16),n.set("keyword",17),n.set("snippet",27),n.set("text",18),n.set("color",19),n.set("file",20),n.set("reference",21),n.set("customcolor",22),n.set("folder",23),n.set("type-parameter",24),n.set("typeParameter",24),n.set("account",25),n.set("issue",26),e.fromString=function(e,t){let r=n.get(e);return"undefined"!==typeof r||t||(r=9),r}}(c||(c={})),function(e){e[e.Automatic=0]="Automatic",e[e.Explicit=1]="Explicit"}(h||(h={}));!function(e){e[e.Automatic=0]="Automatic",e[e.PasteAs=1]="PasteAs"}(u||(u={})),function(e){e[e.Invoke=1]="Invoke",e[e.TriggerCharacter=2]="TriggerCharacter",e[e.ContentChange=3]="ContentChange"}(d||(d={})),function(e){e[e.Text=0]="Text",e[e.Read=1]="Read",e[e.Write=2]="Write"}(g||(g={}));(0,f.kg)("Array","array"),(0,f.kg)("Boolean","boolean"),(0,f.kg)("Class","class"),(0,f.kg)("Constant","constant"),(0,f.kg)("Constructor","constructor"),(0,f.kg)("Enum","enumeration"),(0,f.kg)("EnumMember","enumeration member"),(0,f.kg)("Event","event"),(0,f.kg)("Field","field"),(0,f.kg)("File","file"),(0,f.kg)("Function","function"),(0,f.kg)("Interface","interface"),(0,f.kg)("Key","key"),(0,f.kg)("Method","method"),(0,f.kg)("Module","module"),(0,f.kg)("Namespace","namespace"),(0,f.kg)("Null","null"),(0,f.kg)("Number","number"),(0,f.kg)("Object","object"),(0,f.kg)("Operator","operator"),(0,f.kg)("Package","package"),(0,f.kg)("Property","property"),(0,f.kg)("String","string"),(0,f.kg)("Struct","struct"),(0,f.kg)("TypeParameter","type parameter"),(0,f.kg)("Variable","variable");var b,_,k,v,C;!function(e){const t=new Map;t.set(0,r.W.symbolFile),t.set(1,r.W.symbolModule),t.set(2,r.W.symbolNamespace),t.set(3,r.W.symbolPackage),t.set(4,r.W.symbolClass),t.set(5,r.W.symbolMethod),t.set(6,r.W.symbolProperty),t.set(7,r.W.symbolField),t.set(8,r.W.symbolConstructor),t.set(9,r.W.symbolEnum),t.set(10,r.W.symbolInterface),t.set(11,r.W.symbolFunction),t.set(12,r.W.symbolVariable),t.set(13,r.W.symbolConstant),t.set(14,r.W.symbolString),t.set(15,r.W.symbolNumber),t.set(16,r.W.symbolBoolean),t.set(17,r.W.symbolArray),t.set(18,r.W.symbolObject),t.set(19,r.W.symbolKey),t.set(20,r.W.symbolNull),t.set(21,r.W.symbolEnumMember),t.set(22,r.W.symbolStruct),t.set(23,r.W.symbolEvent),t.set(24,r.W.symbolOperator),t.set(25,r.W.symbolTypeParameter),e.toIcon=function(e){let n=t.get(e);return n||(console.info("No codicon found for SymbolKind "+e),n=r.W.symbolProperty),n}}(b||(b={}));class y{static{this.Comment=new y("comment")}static{this.Imports=new y("imports")}static{this.Region=new y("region")}static fromValue(e){switch(e){case"comment":return y.Comment;case"imports":return y.Imports;case"region":return y.Region}return new y(e)}constructor(e){this.value=e}}!function(e){e[e.AIGenerated=1]="AIGenerated"}(_||(_={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(k||(k={})),function(e){e.is=function(e){return!(!e||"object"!==typeof e)&&("string"===typeof e.id&&"string"===typeof e.title)}}(v||(v={})),function(e){e[e.Type=1]="Type",e[e.Parameter=2]="Parameter"}(C||(C={}));const L=new o,w=new o;var S;!function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(S||(S={}))},154:(e,t,n)=>{"use strict";n.d(t,{L:()=>r});const r=(0,n(3591).u1)("languageService")},3941:(e,t,n)=>{"use strict";n.d(t,{W6:()=>l,vH:()=>c});var r=n(8209),i=n(1234),s=n(6359),o=n(1939),a=n(1646);const l=new class{constructor(){this._onDidChangeLanguages=new i.vl,this.onDidChangeLanguages=this._onDidChangeLanguages.event,this._languages=[]}registerLanguage(e){return this._languages.push(e),this._onDidChangeLanguages.fire(void 0),{dispose:()=>{for(let t=0,n=this._languages.length;t{"use strict";n.d(t,{A5:()=>r,Dg:()=>l,F4:()=>d,L5:()=>u,Wo:()=>h,X2:()=>a,ZS:()=>i,nk:()=>c,vd:()=>g});var r,i,s,o=n(146);!function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=4]="Right",e[e.Full=7]="Full"}(r||(r={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=3]="Right"}(i||(i={})),function(e){e[e.Both=0]="Both",e[e.Right=1]="Right",e[e.Left=2]="Left",e[e.None=3]="None"}(s||(s={}));class a{get originalIndentSize(){return this._indentSizeIsTabSize?"tabSize":this.indentSize}constructor(e){this._textModelResolvedOptionsBrand=void 0,this.tabSize=Math.max(1,0|e.tabSize),"tabSize"===e.indentSize?(this.indentSize=this.tabSize,this._indentSizeIsTabSize=!0):(this.indentSize=Math.max(1,0|e.indentSize),this._indentSizeIsTabSize=!1),this.insertSpaces=Boolean(e.insertSpaces),this.defaultEOL=0|e.defaultEOL,this.trimAutoWhitespace=Boolean(e.trimAutoWhitespace),this.bracketPairColorizationOptions=e.bracketPairColorizationOptions}equals(e){return this.tabSize===e.tabSize&&this._indentSizeIsTabSize===e._indentSizeIsTabSize&&this.indentSize===e.indentSize&&this.insertSpaces===e.insertSpaces&&this.defaultEOL===e.defaultEOL&&this.trimAutoWhitespace===e.trimAutoWhitespace&&(0,o.aI)(this.bracketPairColorizationOptions,e.bracketPairColorizationOptions)}createChangeEvent(e){return{tabSize:this.tabSize!==e.tabSize,indentSize:this.indentSize!==e.indentSize,insertSpaces:this.insertSpaces!==e.insertSpaces,trimAutoWhitespace:this.trimAutoWhitespace!==e.trimAutoWhitespace}}}class l{constructor(e,t){this._findMatchBrand=void 0,this.range=e,this.matches=t}}function c(e){return e&&"function"===typeof e.read}class h{constructor(e,t,n,r,i,s){this.identifier=e,this.range=t,this.text=n,this.forceMoveMarkers=r,this.isAutoWhitespaceEdit=i,this._isTracked=s}}class u{constructor(e,t,n){this.regex=e,this.wordSeparators=t,this.simpleSearch=n}}class d{constructor(e,t,n){this.reverseEdits=e,this.changes=t,this.trimAutoWhitespaceLineNumbers=n}}function g(e){return!e.isTooLargeForSyncing()&&!e.isForSimpleWidget}},7729:(e,t,n)=>{"use strict";n.d(t,{lt:()=>u,W5:()=>p,hB:()=>f,dr:()=>d,wC:()=>m});var r=n(1508),i=n(4320),s=n(534);class o extends s.V{constructor(e,t){super(0),this._segmenter=null,this._cachedLine=null,this._cachedSegments=[],this.intlSegmenterLocales=t,this.intlSegmenterLocales.length>0?this._segmenter=new Intl.Segmenter(this.intlSegmenterLocales,{granularity:"word"}):this._segmenter=null;for(let n=0,r=e.length;nt)break;n=r}return n}findNextIntlWordAtOrAfterOffset(e,t){for(const n of this._getIntlSegmenterWordsOnLine(e))if(!(n.index=n)break;const r=e.charCodeAt(t);if(110===r||114===r||87===r)return!0}}return!1}(this.searchString):this.searchString.indexOf("\n")>=0;let t=null;try{t=r.OS(this.searchString,this.isRegex,{matchCase:this.matchCase,wholeWord:!1,multiline:e,global:!0,unicode:!0})}catch(i){return null}if(!t)return null;let n=!this.isRegex&&!e;return n&&this.searchString.toLowerCase()!==this.searchString.toUpperCase()&&(n=this.matchCase),new h.L5(t,this.wordSeparators?function(e,t){const n=`${e}/${t.join(",")}`;let r=a.get(n);return r||(r=new o(e,t),a.set(n,r)),r}(this.wordSeparators,[]):null,n?this.searchString:null)}}function d(e,t,n){if(!n)return new h.Dg(e,null);const r=[];for(let i=0,s=t.length;i=e?r=i-1:t[i+1]>=e?(n=i,r=i):n=i+1}return n+1}}class f{static findMatches(e,t,n,r,i){const s=t.parseSearchRequest();return s?s.regex.multiline?this._doFindMatchesMultiline(e,n,new p(s.wordSeparators,s.regex),r,i):this._doFindMatchesLineByLine(e,n,s,r,i):[]}static _getMultilineMatchRange(e,t,n,r,i,s){let o,a,l=0;if(r?(l=r.findLineFeedCountBeforeOffset(i),o=t+i+l):o=t+i,r){const e=r.findLineFeedCountBeforeOffset(i+s.length)-l;a=o+s.length+e}else a=o+s.length;const h=e.getPositionAt(o),u=e.getPositionAt(a);return new c.Q(h.lineNumber,h.column,u.lineNumber,u.column)}static _doFindMatchesMultiline(e,t,n,r,i){const s=e.getOffsetAt(t.getStartPosition()),o=e.getValueInRange(t,1),a="\r\n"===e.getEOL()?new g(o):null,l=[];let c,h=0;for(n.reset(0);c=n.next(o);)if(l[h++]=d(this._getMultilineMatchRange(e,s,o,a,c.index,c[0]),c,r),h>=i)return l;return l}static _doFindMatchesLineByLine(e,t,n,r,i){const s=[];let o=0;if(t.startLineNumber===t.endLineNumber){const a=e.getLineContent(t.startLineNumber).substring(t.startColumn-1,t.endColumn-1);return o=this._findMatchesInLine(n,a,t.startLineNumber,t.startColumn-1,o,s,r,i),s}const a=e.getLineContent(t.startLineNumber).substring(t.startColumn-1);o=this._findMatchesInLine(n,a,t.startLineNumber,t.startColumn-1,o,s,r,i);for(let l=t.startLineNumber+1;l=a))return i;return i}const u=new p(e.wordSeparators,e.regex);let g;u.reset(0);do{if(g=u.next(t),g&&(s[i++]=d(new c.Q(n,g.index+1+r,n,g.index+1+g[0].length+r),g,o),i>=a))return i}while(g);return i}static findNextMatch(e,t,n,r){const i=t.parseSearchRequest();if(!i)return null;const s=new p(i.wordSeparators,i.regex);return i.regex.multiline?this._doFindNextMatchMultiline(e,n,s,r):this._doFindNextMatchLineByLine(e,n,s,r)}static _doFindNextMatchMultiline(e,t,n,r){const i=new l.y(t.lineNumber,1),s=e.getOffsetAt(i),o=e.getLineCount(),a=e.getValueInRange(new c.Q(i.lineNumber,i.column,o,e.getLineMaxColumn(o)),1),h="\r\n"===e.getEOL()?new g(a):null;n.reset(t.column-1);const u=n.next(a);return u?d(this._getMultilineMatchRange(e,s,a,h,u.index,u[0]),u,r):1!==t.lineNumber||1!==t.column?this._doFindNextMatchMultiline(e,new l.y(1,1),n,r):null}static _doFindNextMatchLineByLine(e,t,n,r){const i=e.getLineCount(),s=t.lineNumber,o=e.getLineContent(s),a=this._findFirstMatchInLine(n,o,s,t.column,r);if(a)return a;for(let l=1;l<=i;l++){const t=(s+l-1)%i,o=e.getLineContent(t+1),a=this._findFirstMatchInLine(n,o,t+1,1,r);if(a)return a}return null}static _findFirstMatchInLine(e,t,n,r,i){e.reset(r-1);const s=e.next(t);return s?d(new c.Q(n,s.index+1,n,s.index+1+s[0].length),s,i):null}static findPreviousMatch(e,t,n,r){const i=t.parseSearchRequest();if(!i)return null;const s=new p(i.wordSeparators,i.regex);return i.regex.multiline?this._doFindPreviousMatchMultiline(e,n,s,r):this._doFindPreviousMatchLineByLine(e,n,s,r)}static _doFindPreviousMatchMultiline(e,t,n,r){const i=this._doFindMatchesMultiline(e,new c.Q(1,1,t.lineNumber,t.column),n,r,9990);if(i.length>0)return i[i.length-1];const s=e.getLineCount();return t.lineNumber!==s||t.column!==e.getLineMaxColumn(s)?this._doFindPreviousMatchMultiline(e,new l.y(s,e.getLineMaxColumn(s)),n,r):null}static _doFindPreviousMatchLineByLine(e,t,n,r){const i=e.getLineCount(),s=t.lineNumber,o=e.getLineContent(s).substring(0,t.column-1),a=this._findLastMatchInLine(n,o,s,r);if(a)return a;for(let l=1;l<=i;l++){const t=(i+s-l-1)%i,o=e.getLineContent(t+1),a=this._findLastMatchInLine(n,o,t+1,r);if(a)return a}return null}static _findLastMatchInLine(e,t,n,r){let i,s=null;for(e.reset(0);i=e.next(t);)s=d(new c.Q(n,i.index+1,n,i.index+1+i[0].length),i,r);return s}}function m(e,t,n,r,i){return function(e,t,n,r,i){if(0===r)return!0;const s=t.charCodeAt(r-1);if(0!==e.get(s))return!0;if(13===s||10===s)return!0;if(i>0){const n=t.charCodeAt(r);if(0!==e.get(n))return!0}return!1}(e,t,0,r,i)&&function(e,t,n,r,i){if(r+i===n)return!0;const s=t.charCodeAt(r+i);if(0!==e.get(s))return!0;if(13===s||10===s)return!0;if(i>0){const n=t.charCodeAt(r+i-1);if(0!==e.get(n))return!0}return!1}(e,t,n,r,i)}class p{constructor(e,t){this._wordSeparators=e,this._searchRegex=t,this._prevMatchStartIndex=-1,this._prevMatchLength=0}reset(e){this._searchRegex.lastIndex=e,this._prevMatchStartIndex=-1,this._prevMatchLength=0}next(e){const t=e.length;let n;do{if(this._prevMatchStartIndex+this._prevMatchLength===t)return null;if(n=this._searchRegex.exec(e),!n)return null;const i=n.index,s=n[0].length;if(i===this._prevMatchStartIndex&&s===this._prevMatchLength){if(0===s){r.Z5(e,t,this._searchRegex.lastIndex)>65535?this._searchRegex.lastIndex+=2:this._searchRegex.lastIndex+=1;continue}return null}if(this._prevMatchStartIndex=i,this._prevMatchLength=s,!this._wordSeparators||m(this._wordSeparators,e,t,i,s))return n}while(n);return null}}},4272:(e,t,n)=>{"use strict";n.r(t),n.d(t,{KeyMod:()=>fe,createMonacoBaseAPI:()=>me});var r=n(8447),i=n(1234);class s{constructor(){this._keyCodeToStr=[],this._strToKeyCode=Object.create(null)}define(e,t){this._keyCodeToStr[e]=t,this._strToKeyCode[t.toLowerCase()]=e}keyCodeToStr(e){return this._keyCodeToStr[e]}strToKeyCode(e){return this._strToKeyCode[e.toLowerCase()]||0}}const o=new s,a=new s,l=new s,c=new Array(230),h={},u=[],d=Object.create(null),g=Object.create(null),f=[],m=[];for(let pe=0;pe<=193;pe++)f[pe]=-1;for(let pe=0;pe<=132;pe++)m[pe]=-1;var p;!function(){const e="",t=[[1,0,"None",0,"unknown",0,"VK_UNKNOWN",e,e],[1,1,"Hyper",0,e,0,e,e,e],[1,2,"Super",0,e,0,e,e,e],[1,3,"Fn",0,e,0,e,e,e],[1,4,"FnLock",0,e,0,e,e,e],[1,5,"Suspend",0,e,0,e,e,e],[1,6,"Resume",0,e,0,e,e,e],[1,7,"Turbo",0,e,0,e,e,e],[1,8,"Sleep",0,e,0,"VK_SLEEP",e,e],[1,9,"WakeUp",0,e,0,e,e,e],[0,10,"KeyA",31,"A",65,"VK_A",e,e],[0,11,"KeyB",32,"B",66,"VK_B",e,e],[0,12,"KeyC",33,"C",67,"VK_C",e,e],[0,13,"KeyD",34,"D",68,"VK_D",e,e],[0,14,"KeyE",35,"E",69,"VK_E",e,e],[0,15,"KeyF",36,"F",70,"VK_F",e,e],[0,16,"KeyG",37,"G",71,"VK_G",e,e],[0,17,"KeyH",38,"H",72,"VK_H",e,e],[0,18,"KeyI",39,"I",73,"VK_I",e,e],[0,19,"KeyJ",40,"J",74,"VK_J",e,e],[0,20,"KeyK",41,"K",75,"VK_K",e,e],[0,21,"KeyL",42,"L",76,"VK_L",e,e],[0,22,"KeyM",43,"M",77,"VK_M",e,e],[0,23,"KeyN",44,"N",78,"VK_N",e,e],[0,24,"KeyO",45,"O",79,"VK_O",e,e],[0,25,"KeyP",46,"P",80,"VK_P",e,e],[0,26,"KeyQ",47,"Q",81,"VK_Q",e,e],[0,27,"KeyR",48,"R",82,"VK_R",e,e],[0,28,"KeyS",49,"S",83,"VK_S",e,e],[0,29,"KeyT",50,"T",84,"VK_T",e,e],[0,30,"KeyU",51,"U",85,"VK_U",e,e],[0,31,"KeyV",52,"V",86,"VK_V",e,e],[0,32,"KeyW",53,"W",87,"VK_W",e,e],[0,33,"KeyX",54,"X",88,"VK_X",e,e],[0,34,"KeyY",55,"Y",89,"VK_Y",e,e],[0,35,"KeyZ",56,"Z",90,"VK_Z",e,e],[0,36,"Digit1",22,"1",49,"VK_1",e,e],[0,37,"Digit2",23,"2",50,"VK_2",e,e],[0,38,"Digit3",24,"3",51,"VK_3",e,e],[0,39,"Digit4",25,"4",52,"VK_4",e,e],[0,40,"Digit5",26,"5",53,"VK_5",e,e],[0,41,"Digit6",27,"6",54,"VK_6",e,e],[0,42,"Digit7",28,"7",55,"VK_7",e,e],[0,43,"Digit8",29,"8",56,"VK_8",e,e],[0,44,"Digit9",30,"9",57,"VK_9",e,e],[0,45,"Digit0",21,"0",48,"VK_0",e,e],[1,46,"Enter",3,"Enter",13,"VK_RETURN",e,e],[1,47,"Escape",9,"Escape",27,"VK_ESCAPE",e,e],[1,48,"Backspace",1,"Backspace",8,"VK_BACK",e,e],[1,49,"Tab",2,"Tab",9,"VK_TAB",e,e],[1,50,"Space",10,"Space",32,"VK_SPACE",e,e],[0,51,"Minus",88,"-",189,"VK_OEM_MINUS","-","OEM_MINUS"],[0,52,"Equal",86,"=",187,"VK_OEM_PLUS","=","OEM_PLUS"],[0,53,"BracketLeft",92,"[",219,"VK_OEM_4","[","OEM_4"],[0,54,"BracketRight",94,"]",221,"VK_OEM_6","]","OEM_6"],[0,55,"Backslash",93,"\\",220,"VK_OEM_5","\\","OEM_5"],[0,56,"IntlHash",0,e,0,e,e,e],[0,57,"Semicolon",85,";",186,"VK_OEM_1",";","OEM_1"],[0,58,"Quote",95,"'",222,"VK_OEM_7","'","OEM_7"],[0,59,"Backquote",91,"`",192,"VK_OEM_3","`","OEM_3"],[0,60,"Comma",87,",",188,"VK_OEM_COMMA",",","OEM_COMMA"],[0,61,"Period",89,".",190,"VK_OEM_PERIOD",".","OEM_PERIOD"],[0,62,"Slash",90,"/",191,"VK_OEM_2","/","OEM_2"],[1,63,"CapsLock",8,"CapsLock",20,"VK_CAPITAL",e,e],[1,64,"F1",59,"F1",112,"VK_F1",e,e],[1,65,"F2",60,"F2",113,"VK_F2",e,e],[1,66,"F3",61,"F3",114,"VK_F3",e,e],[1,67,"F4",62,"F4",115,"VK_F4",e,e],[1,68,"F5",63,"F5",116,"VK_F5",e,e],[1,69,"F6",64,"F6",117,"VK_F6",e,e],[1,70,"F7",65,"F7",118,"VK_F7",e,e],[1,71,"F8",66,"F8",119,"VK_F8",e,e],[1,72,"F9",67,"F9",120,"VK_F9",e,e],[1,73,"F10",68,"F10",121,"VK_F10",e,e],[1,74,"F11",69,"F11",122,"VK_F11",e,e],[1,75,"F12",70,"F12",123,"VK_F12",e,e],[1,76,"PrintScreen",0,e,0,e,e,e],[1,77,"ScrollLock",84,"ScrollLock",145,"VK_SCROLL",e,e],[1,78,"Pause",7,"PauseBreak",19,"VK_PAUSE",e,e],[1,79,"Insert",19,"Insert",45,"VK_INSERT",e,e],[1,80,"Home",14,"Home",36,"VK_HOME",e,e],[1,81,"PageUp",11,"PageUp",33,"VK_PRIOR",e,e],[1,82,"Delete",20,"Delete",46,"VK_DELETE",e,e],[1,83,"End",13,"End",35,"VK_END",e,e],[1,84,"PageDown",12,"PageDown",34,"VK_NEXT",e,e],[1,85,"ArrowRight",17,"RightArrow",39,"VK_RIGHT","Right",e],[1,86,"ArrowLeft",15,"LeftArrow",37,"VK_LEFT","Left",e],[1,87,"ArrowDown",18,"DownArrow",40,"VK_DOWN","Down",e],[1,88,"ArrowUp",16,"UpArrow",38,"VK_UP","Up",e],[1,89,"NumLock",83,"NumLock",144,"VK_NUMLOCK",e,e],[1,90,"NumpadDivide",113,"NumPad_Divide",111,"VK_DIVIDE",e,e],[1,91,"NumpadMultiply",108,"NumPad_Multiply",106,"VK_MULTIPLY",e,e],[1,92,"NumpadSubtract",111,"NumPad_Subtract",109,"VK_SUBTRACT",e,e],[1,93,"NumpadAdd",109,"NumPad_Add",107,"VK_ADD",e,e],[1,94,"NumpadEnter",3,e,0,e,e,e],[1,95,"Numpad1",99,"NumPad1",97,"VK_NUMPAD1",e,e],[1,96,"Numpad2",100,"NumPad2",98,"VK_NUMPAD2",e,e],[1,97,"Numpad3",101,"NumPad3",99,"VK_NUMPAD3",e,e],[1,98,"Numpad4",102,"NumPad4",100,"VK_NUMPAD4",e,e],[1,99,"Numpad5",103,"NumPad5",101,"VK_NUMPAD5",e,e],[1,100,"Numpad6",104,"NumPad6",102,"VK_NUMPAD6",e,e],[1,101,"Numpad7",105,"NumPad7",103,"VK_NUMPAD7",e,e],[1,102,"Numpad8",106,"NumPad8",104,"VK_NUMPAD8",e,e],[1,103,"Numpad9",107,"NumPad9",105,"VK_NUMPAD9",e,e],[1,104,"Numpad0",98,"NumPad0",96,"VK_NUMPAD0",e,e],[1,105,"NumpadDecimal",112,"NumPad_Decimal",110,"VK_DECIMAL",e,e],[0,106,"IntlBackslash",97,"OEM_102",226,"VK_OEM_102",e,e],[1,107,"ContextMenu",58,"ContextMenu",93,e,e,e],[1,108,"Power",0,e,0,e,e,e],[1,109,"NumpadEqual",0,e,0,e,e,e],[1,110,"F13",71,"F13",124,"VK_F13",e,e],[1,111,"F14",72,"F14",125,"VK_F14",e,e],[1,112,"F15",73,"F15",126,"VK_F15",e,e],[1,113,"F16",74,"F16",127,"VK_F16",e,e],[1,114,"F17",75,"F17",128,"VK_F17",e,e],[1,115,"F18",76,"F18",129,"VK_F18",e,e],[1,116,"F19",77,"F19",130,"VK_F19",e,e],[1,117,"F20",78,"F20",131,"VK_F20",e,e],[1,118,"F21",79,"F21",132,"VK_F21",e,e],[1,119,"F22",80,"F22",133,"VK_F22",e,e],[1,120,"F23",81,"F23",134,"VK_F23",e,e],[1,121,"F24",82,"F24",135,"VK_F24",e,e],[1,122,"Open",0,e,0,e,e,e],[1,123,"Help",0,e,0,e,e,e],[1,124,"Select",0,e,0,e,e,e],[1,125,"Again",0,e,0,e,e,e],[1,126,"Undo",0,e,0,e,e,e],[1,127,"Cut",0,e,0,e,e,e],[1,128,"Copy",0,e,0,e,e,e],[1,129,"Paste",0,e,0,e,e,e],[1,130,"Find",0,e,0,e,e,e],[1,131,"AudioVolumeMute",117,"AudioVolumeMute",173,"VK_VOLUME_MUTE",e,e],[1,132,"AudioVolumeUp",118,"AudioVolumeUp",175,"VK_VOLUME_UP",e,e],[1,133,"AudioVolumeDown",119,"AudioVolumeDown",174,"VK_VOLUME_DOWN",e,e],[1,134,"NumpadComma",110,"NumPad_Separator",108,"VK_SEPARATOR",e,e],[0,135,"IntlRo",115,"ABNT_C1",193,"VK_ABNT_C1",e,e],[1,136,"KanaMode",0,e,0,e,e,e],[0,137,"IntlYen",0,e,0,e,e,e],[1,138,"Convert",0,e,0,e,e,e],[1,139,"NonConvert",0,e,0,e,e,e],[1,140,"Lang1",0,e,0,e,e,e],[1,141,"Lang2",0,e,0,e,e,e],[1,142,"Lang3",0,e,0,e,e,e],[1,143,"Lang4",0,e,0,e,e,e],[1,144,"Lang5",0,e,0,e,e,e],[1,145,"Abort",0,e,0,e,e,e],[1,146,"Props",0,e,0,e,e,e],[1,147,"NumpadParenLeft",0,e,0,e,e,e],[1,148,"NumpadParenRight",0,e,0,e,e,e],[1,149,"NumpadBackspace",0,e,0,e,e,e],[1,150,"NumpadMemoryStore",0,e,0,e,e,e],[1,151,"NumpadMemoryRecall",0,e,0,e,e,e],[1,152,"NumpadMemoryClear",0,e,0,e,e,e],[1,153,"NumpadMemoryAdd",0,e,0,e,e,e],[1,154,"NumpadMemorySubtract",0,e,0,e,e,e],[1,155,"NumpadClear",131,"Clear",12,"VK_CLEAR",e,e],[1,156,"NumpadClearEntry",0,e,0,e,e,e],[1,0,e,5,"Ctrl",17,"VK_CONTROL",e,e],[1,0,e,4,"Shift",16,"VK_SHIFT",e,e],[1,0,e,6,"Alt",18,"VK_MENU",e,e],[1,0,e,57,"Meta",91,"VK_COMMAND",e,e],[1,157,"ControlLeft",5,e,0,"VK_LCONTROL",e,e],[1,158,"ShiftLeft",4,e,0,"VK_LSHIFT",e,e],[1,159,"AltLeft",6,e,0,"VK_LMENU",e,e],[1,160,"MetaLeft",57,e,0,"VK_LWIN",e,e],[1,161,"ControlRight",5,e,0,"VK_RCONTROL",e,e],[1,162,"ShiftRight",4,e,0,"VK_RSHIFT",e,e],[1,163,"AltRight",6,e,0,"VK_RMENU",e,e],[1,164,"MetaRight",57,e,0,"VK_RWIN",e,e],[1,165,"BrightnessUp",0,e,0,e,e,e],[1,166,"BrightnessDown",0,e,0,e,e,e],[1,167,"MediaPlay",0,e,0,e,e,e],[1,168,"MediaRecord",0,e,0,e,e,e],[1,169,"MediaFastForward",0,e,0,e,e,e],[1,170,"MediaRewind",0,e,0,e,e,e],[1,171,"MediaTrackNext",124,"MediaTrackNext",176,"VK_MEDIA_NEXT_TRACK",e,e],[1,172,"MediaTrackPrevious",125,"MediaTrackPrevious",177,"VK_MEDIA_PREV_TRACK",e,e],[1,173,"MediaStop",126,"MediaStop",178,"VK_MEDIA_STOP",e,e],[1,174,"Eject",0,e,0,e,e,e],[1,175,"MediaPlayPause",127,"MediaPlayPause",179,"VK_MEDIA_PLAY_PAUSE",e,e],[1,176,"MediaSelect",128,"LaunchMediaPlayer",181,"VK_MEDIA_LAUNCH_MEDIA_SELECT",e,e],[1,177,"LaunchMail",129,"LaunchMail",180,"VK_MEDIA_LAUNCH_MAIL",e,e],[1,178,"LaunchApp2",130,"LaunchApp2",183,"VK_MEDIA_LAUNCH_APP2",e,e],[1,179,"LaunchApp1",0,e,0,"VK_MEDIA_LAUNCH_APP1",e,e],[1,180,"SelectTask",0,e,0,e,e,e],[1,181,"LaunchScreenSaver",0,e,0,e,e,e],[1,182,"BrowserSearch",120,"BrowserSearch",170,"VK_BROWSER_SEARCH",e,e],[1,183,"BrowserHome",121,"BrowserHome",172,"VK_BROWSER_HOME",e,e],[1,184,"BrowserBack",122,"BrowserBack",166,"VK_BROWSER_BACK",e,e],[1,185,"BrowserForward",123,"BrowserForward",167,"VK_BROWSER_FORWARD",e,e],[1,186,"BrowserStop",0,e,0,"VK_BROWSER_STOP",e,e],[1,187,"BrowserRefresh",0,e,0,"VK_BROWSER_REFRESH",e,e],[1,188,"BrowserFavorites",0,e,0,"VK_BROWSER_FAVORITES",e,e],[1,189,"ZoomToggle",0,e,0,e,e,e],[1,190,"MailReply",0,e,0,e,e,e],[1,191,"MailForward",0,e,0,e,e,e],[1,192,"MailSend",0,e,0,e,e,e],[1,0,e,114,"KeyInComposition",229,e,e,e],[1,0,e,116,"ABNT_C2",194,"VK_ABNT_C2",e,e],[1,0,e,96,"OEM_8",223,"VK_OEM_8",e,e],[1,0,e,0,e,0,"VK_KANA",e,e],[1,0,e,0,e,0,"VK_HANGUL",e,e],[1,0,e,0,e,0,"VK_JUNJA",e,e],[1,0,e,0,e,0,"VK_FINAL",e,e],[1,0,e,0,e,0,"VK_HANJA",e,e],[1,0,e,0,e,0,"VK_KANJI",e,e],[1,0,e,0,e,0,"VK_CONVERT",e,e],[1,0,e,0,e,0,"VK_NONCONVERT",e,e],[1,0,e,0,e,0,"VK_ACCEPT",e,e],[1,0,e,0,e,0,"VK_MODECHANGE",e,e],[1,0,e,0,e,0,"VK_SELECT",e,e],[1,0,e,0,e,0,"VK_PRINT",e,e],[1,0,e,0,e,0,"VK_EXECUTE",e,e],[1,0,e,0,e,0,"VK_SNAPSHOT",e,e],[1,0,e,0,e,0,"VK_HELP",e,e],[1,0,e,0,e,0,"VK_APPS",e,e],[1,0,e,0,e,0,"VK_PROCESSKEY",e,e],[1,0,e,0,e,0,"VK_PACKET",e,e],[1,0,e,0,e,0,"VK_DBE_SBCSCHAR",e,e],[1,0,e,0,e,0,"VK_DBE_DBCSCHAR",e,e],[1,0,e,0,e,0,"VK_ATTN",e,e],[1,0,e,0,e,0,"VK_CRSEL",e,e],[1,0,e,0,e,0,"VK_EXSEL",e,e],[1,0,e,0,e,0,"VK_EREOF",e,e],[1,0,e,0,e,0,"VK_PLAY",e,e],[1,0,e,0,e,0,"VK_ZOOM",e,e],[1,0,e,0,e,0,"VK_NONAME",e,e],[1,0,e,0,e,0,"VK_PA1",e,e],[1,0,e,0,e,0,"VK_OEM_CLEAR",e,e]],n=[],r=[];for(const i of t){const[e,t,s,p,b,_,k,v,C]=i;if(r[t]||(r[t]=!0,u[t]=s,d[s]=t,g[s.toLowerCase()]=t,e&&(f[t]=p,0!==p&&3!==p&&5!==p&&4!==p&&6!==p&&57!==p&&(m[p]=t))),!n[p]){if(n[p]=!0,!b)throw new Error(`String representation missing for key code ${p} around scan code ${s}`);o.define(p,b),a.define(p,v||b),l.define(p,C||v||b)}_&&(c[_]=p),k&&(h[k]=p)}m[3]=46}(),function(e){e.toString=function(e){return o.keyCodeToStr(e)},e.fromString=function(e){return o.strToKeyCode(e)},e.toUserSettingsUS=function(e){return a.keyCodeToStr(e)},e.toUserSettingsGeneral=function(e){return l.keyCodeToStr(e)},e.fromUserSettings=function(e){return a.strToKeyCode(e)||l.strToKeyCode(e)},e.toElectronAccelerator=function(e){if(e>=98&&e<=113)return null;switch(e){case 16:return"Up";case 18:return"Down";case 15:return"Left";case 17:return"Right"}return o.keyCodeToStr(e)}}(p||(p={}));var b,_,k,v,C,y,L,w,S,x,E,N,T,A,I,O,M,R,D,B,F,P,V,z,j,q,W,U,$,H,K,G,Q,J,X,Y,Z,ee,te,ne,re,ie,se,oe,ae,le,ce=n(9400),he=n(3069),ue=n(6677),de=n(5326),ge=n(2083);!function(e){e[e.Unknown=0]="Unknown",e[e.Disabled=1]="Disabled",e[e.Enabled=2]="Enabled"}(b||(b={})),function(e){e[e.Invoke=1]="Invoke",e[e.Auto=2]="Auto"}(_||(_={})),function(e){e[e.None=0]="None",e[e.KeepWhitespace=1]="KeepWhitespace",e[e.InsertAsSnippet=4]="InsertAsSnippet"}(k||(k={})),function(e){e[e.Method=0]="Method",e[e.Function=1]="Function",e[e.Constructor=2]="Constructor",e[e.Field=3]="Field",e[e.Variable=4]="Variable",e[e.Class=5]="Class",e[e.Struct=6]="Struct",e[e.Interface=7]="Interface",e[e.Module=8]="Module",e[e.Property=9]="Property",e[e.Event=10]="Event",e[e.Operator=11]="Operator",e[e.Unit=12]="Unit",e[e.Value=13]="Value",e[e.Constant=14]="Constant",e[e.Enum=15]="Enum",e[e.EnumMember=16]="EnumMember",e[e.Keyword=17]="Keyword",e[e.Text=18]="Text",e[e.Color=19]="Color",e[e.File=20]="File",e[e.Reference=21]="Reference",e[e.Customcolor=22]="Customcolor",e[e.Folder=23]="Folder",e[e.TypeParameter=24]="TypeParameter",e[e.User=25]="User",e[e.Issue=26]="Issue",e[e.Snippet=27]="Snippet"}(v||(v={})),function(e){e[e.Deprecated=1]="Deprecated"}(C||(C={})),function(e){e[e.Invoke=0]="Invoke",e[e.TriggerCharacter=1]="TriggerCharacter",e[e.TriggerForIncompleteCompletions=2]="TriggerForIncompleteCompletions"}(y||(y={})),function(e){e[e.EXACT=0]="EXACT",e[e.ABOVE=1]="ABOVE",e[e.BELOW=2]="BELOW"}(L||(L={})),function(e){e[e.NotSet=0]="NotSet",e[e.ContentFlush=1]="ContentFlush",e[e.RecoverFromMarkers=2]="RecoverFromMarkers",e[e.Explicit=3]="Explicit",e[e.Paste=4]="Paste",e[e.Undo=5]="Undo",e[e.Redo=6]="Redo"}(w||(w={})),function(e){e[e.LF=1]="LF",e[e.CRLF=2]="CRLF"}(S||(S={})),function(e){e[e.Text=0]="Text",e[e.Read=1]="Read",e[e.Write=2]="Write"}(x||(x={})),function(e){e[e.None=0]="None",e[e.Keep=1]="Keep",e[e.Brackets=2]="Brackets",e[e.Advanced=3]="Advanced",e[e.Full=4]="Full"}(E||(E={})),function(e){e[e.acceptSuggestionOnCommitCharacter=0]="acceptSuggestionOnCommitCharacter",e[e.acceptSuggestionOnEnter=1]="acceptSuggestionOnEnter",e[e.accessibilitySupport=2]="accessibilitySupport",e[e.accessibilityPageSize=3]="accessibilityPageSize",e[e.ariaLabel=4]="ariaLabel",e[e.ariaRequired=5]="ariaRequired",e[e.autoClosingBrackets=6]="autoClosingBrackets",e[e.autoClosingComments=7]="autoClosingComments",e[e.screenReaderAnnounceInlineSuggestion=8]="screenReaderAnnounceInlineSuggestion",e[e.autoClosingDelete=9]="autoClosingDelete",e[e.autoClosingOvertype=10]="autoClosingOvertype",e[e.autoClosingQuotes=11]="autoClosingQuotes",e[e.autoIndent=12]="autoIndent",e[e.automaticLayout=13]="automaticLayout",e[e.autoSurround=14]="autoSurround",e[e.bracketPairColorization=15]="bracketPairColorization",e[e.guides=16]="guides",e[e.codeLens=17]="codeLens",e[e.codeLensFontFamily=18]="codeLensFontFamily",e[e.codeLensFontSize=19]="codeLensFontSize",e[e.colorDecorators=20]="colorDecorators",e[e.colorDecoratorsLimit=21]="colorDecoratorsLimit",e[e.columnSelection=22]="columnSelection",e[e.comments=23]="comments",e[e.contextmenu=24]="contextmenu",e[e.copyWithSyntaxHighlighting=25]="copyWithSyntaxHighlighting",e[e.cursorBlinking=26]="cursorBlinking",e[e.cursorSmoothCaretAnimation=27]="cursorSmoothCaretAnimation",e[e.cursorStyle=28]="cursorStyle",e[e.cursorSurroundingLines=29]="cursorSurroundingLines",e[e.cursorSurroundingLinesStyle=30]="cursorSurroundingLinesStyle",e[e.cursorWidth=31]="cursorWidth",e[e.disableLayerHinting=32]="disableLayerHinting",e[e.disableMonospaceOptimizations=33]="disableMonospaceOptimizations",e[e.domReadOnly=34]="domReadOnly",e[e.dragAndDrop=35]="dragAndDrop",e[e.dropIntoEditor=36]="dropIntoEditor",e[e.emptySelectionClipboard=37]="emptySelectionClipboard",e[e.experimentalWhitespaceRendering=38]="experimentalWhitespaceRendering",e[e.extraEditorClassName=39]="extraEditorClassName",e[e.fastScrollSensitivity=40]="fastScrollSensitivity",e[e.find=41]="find",e[e.fixedOverflowWidgets=42]="fixedOverflowWidgets",e[e.folding=43]="folding",e[e.foldingStrategy=44]="foldingStrategy",e[e.foldingHighlight=45]="foldingHighlight",e[e.foldingImportsByDefault=46]="foldingImportsByDefault",e[e.foldingMaximumRegions=47]="foldingMaximumRegions",e[e.unfoldOnClickAfterEndOfLine=48]="unfoldOnClickAfterEndOfLine",e[e.fontFamily=49]="fontFamily",e[e.fontInfo=50]="fontInfo",e[e.fontLigatures=51]="fontLigatures",e[e.fontSize=52]="fontSize",e[e.fontWeight=53]="fontWeight",e[e.fontVariations=54]="fontVariations",e[e.formatOnPaste=55]="formatOnPaste",e[e.formatOnType=56]="formatOnType",e[e.glyphMargin=57]="glyphMargin",e[e.gotoLocation=58]="gotoLocation",e[e.hideCursorInOverviewRuler=59]="hideCursorInOverviewRuler",e[e.hover=60]="hover",e[e.inDiffEditor=61]="inDiffEditor",e[e.inlineSuggest=62]="inlineSuggest",e[e.inlineEdit=63]="inlineEdit",e[e.letterSpacing=64]="letterSpacing",e[e.lightbulb=65]="lightbulb",e[e.lineDecorationsWidth=66]="lineDecorationsWidth",e[e.lineHeight=67]="lineHeight",e[e.lineNumbers=68]="lineNumbers",e[e.lineNumbersMinChars=69]="lineNumbersMinChars",e[e.linkedEditing=70]="linkedEditing",e[e.links=71]="links",e[e.matchBrackets=72]="matchBrackets",e[e.minimap=73]="minimap",e[e.mouseStyle=74]="mouseStyle",e[e.mouseWheelScrollSensitivity=75]="mouseWheelScrollSensitivity",e[e.mouseWheelZoom=76]="mouseWheelZoom",e[e.multiCursorMergeOverlapping=77]="multiCursorMergeOverlapping",e[e.multiCursorModifier=78]="multiCursorModifier",e[e.multiCursorPaste=79]="multiCursorPaste",e[e.multiCursorLimit=80]="multiCursorLimit",e[e.occurrencesHighlight=81]="occurrencesHighlight",e[e.overviewRulerBorder=82]="overviewRulerBorder",e[e.overviewRulerLanes=83]="overviewRulerLanes",e[e.padding=84]="padding",e[e.pasteAs=85]="pasteAs",e[e.parameterHints=86]="parameterHints",e[e.peekWidgetDefaultFocus=87]="peekWidgetDefaultFocus",e[e.placeholder=88]="placeholder",e[e.definitionLinkOpensInPeek=89]="definitionLinkOpensInPeek",e[e.quickSuggestions=90]="quickSuggestions",e[e.quickSuggestionsDelay=91]="quickSuggestionsDelay",e[e.readOnly=92]="readOnly",e[e.readOnlyMessage=93]="readOnlyMessage",e[e.renameOnType=94]="renameOnType",e[e.renderControlCharacters=95]="renderControlCharacters",e[e.renderFinalNewline=96]="renderFinalNewline",e[e.renderLineHighlight=97]="renderLineHighlight",e[e.renderLineHighlightOnlyWhenFocus=98]="renderLineHighlightOnlyWhenFocus",e[e.renderValidationDecorations=99]="renderValidationDecorations",e[e.renderWhitespace=100]="renderWhitespace",e[e.revealHorizontalRightPadding=101]="revealHorizontalRightPadding",e[e.roundedSelection=102]="roundedSelection",e[e.rulers=103]="rulers",e[e.scrollbar=104]="scrollbar",e[e.scrollBeyondLastColumn=105]="scrollBeyondLastColumn",e[e.scrollBeyondLastLine=106]="scrollBeyondLastLine",e[e.scrollPredominantAxis=107]="scrollPredominantAxis",e[e.selectionClipboard=108]="selectionClipboard",e[e.selectionHighlight=109]="selectionHighlight",e[e.selectOnLineNumbers=110]="selectOnLineNumbers",e[e.showFoldingControls=111]="showFoldingControls",e[e.showUnused=112]="showUnused",e[e.snippetSuggestions=113]="snippetSuggestions",e[e.smartSelect=114]="smartSelect",e[e.smoothScrolling=115]="smoothScrolling",e[e.stickyScroll=116]="stickyScroll",e[e.stickyTabStops=117]="stickyTabStops",e[e.stopRenderingLineAfter=118]="stopRenderingLineAfter",e[e.suggest=119]="suggest",e[e.suggestFontSize=120]="suggestFontSize",e[e.suggestLineHeight=121]="suggestLineHeight",e[e.suggestOnTriggerCharacters=122]="suggestOnTriggerCharacters",e[e.suggestSelection=123]="suggestSelection",e[e.tabCompletion=124]="tabCompletion",e[e.tabIndex=125]="tabIndex",e[e.unicodeHighlighting=126]="unicodeHighlighting",e[e.unusualLineTerminators=127]="unusualLineTerminators",e[e.useShadowDOM=128]="useShadowDOM",e[e.useTabStops=129]="useTabStops",e[e.wordBreak=130]="wordBreak",e[e.wordSegmenterLocales=131]="wordSegmenterLocales",e[e.wordSeparators=132]="wordSeparators",e[e.wordWrap=133]="wordWrap",e[e.wordWrapBreakAfterCharacters=134]="wordWrapBreakAfterCharacters",e[e.wordWrapBreakBeforeCharacters=135]="wordWrapBreakBeforeCharacters",e[e.wordWrapColumn=136]="wordWrapColumn",e[e.wordWrapOverride1=137]="wordWrapOverride1",e[e.wordWrapOverride2=138]="wordWrapOverride2",e[e.wrappingIndent=139]="wrappingIndent",e[e.wrappingStrategy=140]="wrappingStrategy",e[e.showDeprecated=141]="showDeprecated",e[e.inlayHints=142]="inlayHints",e[e.editorClassName=143]="editorClassName",e[e.pixelRatio=144]="pixelRatio",e[e.tabFocusMode=145]="tabFocusMode",e[e.layoutInfo=146]="layoutInfo",e[e.wrappingInfo=147]="wrappingInfo",e[e.defaultColorDecorators=148]="defaultColorDecorators",e[e.colorDecoratorsActivatedOn=149]="colorDecoratorsActivatedOn",e[e.inlineCompletionsAccessibilityVerbose=150]="inlineCompletionsAccessibilityVerbose"}(N||(N={})),function(e){e[e.TextDefined=0]="TextDefined",e[e.LF=1]="LF",e[e.CRLF=2]="CRLF"}(T||(T={})),function(e){e[e.LF=0]="LF",e[e.CRLF=1]="CRLF"}(A||(A={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=3]="Right"}(I||(I={})),function(e){e[e.Increase=0]="Increase",e[e.Decrease=1]="Decrease"}(O||(O={})),function(e){e[e.None=0]="None",e[e.Indent=1]="Indent",e[e.IndentOutdent=2]="IndentOutdent",e[e.Outdent=3]="Outdent"}(M||(M={})),function(e){e[e.Both=0]="Both",e[e.Right=1]="Right",e[e.Left=2]="Left",e[e.None=3]="None"}(R||(R={})),function(e){e[e.Type=1]="Type",e[e.Parameter=2]="Parameter"}(D||(D={})),function(e){e[e.Automatic=0]="Automatic",e[e.Explicit=1]="Explicit"}(B||(B={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(F||(F={})),function(e){e[e.DependsOnKbLayout=-1]="DependsOnKbLayout",e[e.Unknown=0]="Unknown",e[e.Backspace=1]="Backspace",e[e.Tab=2]="Tab",e[e.Enter=3]="Enter",e[e.Shift=4]="Shift",e[e.Ctrl=5]="Ctrl",e[e.Alt=6]="Alt",e[e.PauseBreak=7]="PauseBreak",e[e.CapsLock=8]="CapsLock",e[e.Escape=9]="Escape",e[e.Space=10]="Space",e[e.PageUp=11]="PageUp",e[e.PageDown=12]="PageDown",e[e.End=13]="End",e[e.Home=14]="Home",e[e.LeftArrow=15]="LeftArrow",e[e.UpArrow=16]="UpArrow",e[e.RightArrow=17]="RightArrow",e[e.DownArrow=18]="DownArrow",e[e.Insert=19]="Insert",e[e.Delete=20]="Delete",e[e.Digit0=21]="Digit0",e[e.Digit1=22]="Digit1",e[e.Digit2=23]="Digit2",e[e.Digit3=24]="Digit3",e[e.Digit4=25]="Digit4",e[e.Digit5=26]="Digit5",e[e.Digit6=27]="Digit6",e[e.Digit7=28]="Digit7",e[e.Digit8=29]="Digit8",e[e.Digit9=30]="Digit9",e[e.KeyA=31]="KeyA",e[e.KeyB=32]="KeyB",e[e.KeyC=33]="KeyC",e[e.KeyD=34]="KeyD",e[e.KeyE=35]="KeyE",e[e.KeyF=36]="KeyF",e[e.KeyG=37]="KeyG",e[e.KeyH=38]="KeyH",e[e.KeyI=39]="KeyI",e[e.KeyJ=40]="KeyJ",e[e.KeyK=41]="KeyK",e[e.KeyL=42]="KeyL",e[e.KeyM=43]="KeyM",e[e.KeyN=44]="KeyN",e[e.KeyO=45]="KeyO",e[e.KeyP=46]="KeyP",e[e.KeyQ=47]="KeyQ",e[e.KeyR=48]="KeyR",e[e.KeyS=49]="KeyS",e[e.KeyT=50]="KeyT",e[e.KeyU=51]="KeyU",e[e.KeyV=52]="KeyV",e[e.KeyW=53]="KeyW",e[e.KeyX=54]="KeyX",e[e.KeyY=55]="KeyY",e[e.KeyZ=56]="KeyZ",e[e.Meta=57]="Meta",e[e.ContextMenu=58]="ContextMenu",e[e.F1=59]="F1",e[e.F2=60]="F2",e[e.F3=61]="F3",e[e.F4=62]="F4",e[e.F5=63]="F5",e[e.F6=64]="F6",e[e.F7=65]="F7",e[e.F8=66]="F8",e[e.F9=67]="F9",e[e.F10=68]="F10",e[e.F11=69]="F11",e[e.F12=70]="F12",e[e.F13=71]="F13",e[e.F14=72]="F14",e[e.F15=73]="F15",e[e.F16=74]="F16",e[e.F17=75]="F17",e[e.F18=76]="F18",e[e.F19=77]="F19",e[e.F20=78]="F20",e[e.F21=79]="F21",e[e.F22=80]="F22",e[e.F23=81]="F23",e[e.F24=82]="F24",e[e.NumLock=83]="NumLock",e[e.ScrollLock=84]="ScrollLock",e[e.Semicolon=85]="Semicolon",e[e.Equal=86]="Equal",e[e.Comma=87]="Comma",e[e.Minus=88]="Minus",e[e.Period=89]="Period",e[e.Slash=90]="Slash",e[e.Backquote=91]="Backquote",e[e.BracketLeft=92]="BracketLeft",e[e.Backslash=93]="Backslash",e[e.BracketRight=94]="BracketRight",e[e.Quote=95]="Quote",e[e.OEM_8=96]="OEM_8",e[e.IntlBackslash=97]="IntlBackslash",e[e.Numpad0=98]="Numpad0",e[e.Numpad1=99]="Numpad1",e[e.Numpad2=100]="Numpad2",e[e.Numpad3=101]="Numpad3",e[e.Numpad4=102]="Numpad4",e[e.Numpad5=103]="Numpad5",e[e.Numpad6=104]="Numpad6",e[e.Numpad7=105]="Numpad7",e[e.Numpad8=106]="Numpad8",e[e.Numpad9=107]="Numpad9",e[e.NumpadMultiply=108]="NumpadMultiply",e[e.NumpadAdd=109]="NumpadAdd",e[e.NUMPAD_SEPARATOR=110]="NUMPAD_SEPARATOR",e[e.NumpadSubtract=111]="NumpadSubtract",e[e.NumpadDecimal=112]="NumpadDecimal",e[e.NumpadDivide=113]="NumpadDivide",e[e.KEY_IN_COMPOSITION=114]="KEY_IN_COMPOSITION",e[e.ABNT_C1=115]="ABNT_C1",e[e.ABNT_C2=116]="ABNT_C2",e[e.AudioVolumeMute=117]="AudioVolumeMute",e[e.AudioVolumeUp=118]="AudioVolumeUp",e[e.AudioVolumeDown=119]="AudioVolumeDown",e[e.BrowserSearch=120]="BrowserSearch",e[e.BrowserHome=121]="BrowserHome",e[e.BrowserBack=122]="BrowserBack",e[e.BrowserForward=123]="BrowserForward",e[e.MediaTrackNext=124]="MediaTrackNext",e[e.MediaTrackPrevious=125]="MediaTrackPrevious",e[e.MediaStop=126]="MediaStop",e[e.MediaPlayPause=127]="MediaPlayPause",e[e.LaunchMediaPlayer=128]="LaunchMediaPlayer",e[e.LaunchMail=129]="LaunchMail",e[e.LaunchApp2=130]="LaunchApp2",e[e.Clear=131]="Clear",e[e.MAX_VALUE=132]="MAX_VALUE"}(P||(P={})),function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(V||(V={})),function(e){e[e.Unnecessary=1]="Unnecessary",e[e.Deprecated=2]="Deprecated"}(z||(z={})),function(e){e[e.Inline=1]="Inline",e[e.Gutter=2]="Gutter"}(j||(j={})),function(e){e[e.Normal=1]="Normal",e[e.Underlined=2]="Underlined"}(q||(q={})),function(e){e[e.UNKNOWN=0]="UNKNOWN",e[e.TEXTAREA=1]="TEXTAREA",e[e.GUTTER_GLYPH_MARGIN=2]="GUTTER_GLYPH_MARGIN",e[e.GUTTER_LINE_NUMBERS=3]="GUTTER_LINE_NUMBERS",e[e.GUTTER_LINE_DECORATIONS=4]="GUTTER_LINE_DECORATIONS",e[e.GUTTER_VIEW_ZONE=5]="GUTTER_VIEW_ZONE",e[e.CONTENT_TEXT=6]="CONTENT_TEXT",e[e.CONTENT_EMPTY=7]="CONTENT_EMPTY",e[e.CONTENT_VIEW_ZONE=8]="CONTENT_VIEW_ZONE",e[e.CONTENT_WIDGET=9]="CONTENT_WIDGET",e[e.OVERVIEW_RULER=10]="OVERVIEW_RULER",e[e.SCROLLBAR=11]="SCROLLBAR",e[e.OVERLAY_WIDGET=12]="OVERLAY_WIDGET",e[e.OUTSIDE_EDITOR=13]="OUTSIDE_EDITOR"}(W||(W={})),function(e){e[e.AIGenerated=1]="AIGenerated"}(U||(U={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}($||($={})),function(e){e[e.TOP_RIGHT_CORNER=0]="TOP_RIGHT_CORNER",e[e.BOTTOM_RIGHT_CORNER=1]="BOTTOM_RIGHT_CORNER",e[e.TOP_CENTER=2]="TOP_CENTER"}(H||(H={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=4]="Right",e[e.Full=7]="Full"}(K||(K={})),function(e){e[e.Word=0]="Word",e[e.Line=1]="Line",e[e.Suggest=2]="Suggest"}(G||(G={})),function(e){e[e.Left=0]="Left",e[e.Right=1]="Right",e[e.None=2]="None",e[e.LeftOfInjectedText=3]="LeftOfInjectedText",e[e.RightOfInjectedText=4]="RightOfInjectedText"}(Q||(Q={})),function(e){e[e.Off=0]="Off",e[e.On=1]="On",e[e.Relative=2]="Relative",e[e.Interval=3]="Interval",e[e.Custom=4]="Custom"}(J||(J={})),function(e){e[e.None=0]="None",e[e.Text=1]="Text",e[e.Blocks=2]="Blocks"}(X||(X={})),function(e){e[e.Smooth=0]="Smooth",e[e.Immediate=1]="Immediate"}(Y||(Y={})),function(e){e[e.Auto=1]="Auto",e[e.Hidden=2]="Hidden",e[e.Visible=3]="Visible"}(Z||(Z={})),function(e){e[e.LTR=0]="LTR",e[e.RTL=1]="RTL"}(ee||(ee={})),function(e){e.Off="off",e.OnCode="onCode",e.On="on"}(te||(te={})),function(e){e[e.Invoke=1]="Invoke",e[e.TriggerCharacter=2]="TriggerCharacter",e[e.ContentChange=3]="ContentChange"}(ne||(ne={})),function(e){e[e.File=0]="File",e[e.Module=1]="Module",e[e.Namespace=2]="Namespace",e[e.Package=3]="Package",e[e.Class=4]="Class",e[e.Method=5]="Method",e[e.Property=6]="Property",e[e.Field=7]="Field",e[e.Constructor=8]="Constructor",e[e.Enum=9]="Enum",e[e.Interface=10]="Interface",e[e.Function=11]="Function",e[e.Variable=12]="Variable",e[e.Constant=13]="Constant",e[e.String=14]="String",e[e.Number=15]="Number",e[e.Boolean=16]="Boolean",e[e.Array=17]="Array",e[e.Object=18]="Object",e[e.Key=19]="Key",e[e.Null=20]="Null",e[e.EnumMember=21]="EnumMember",e[e.Struct=22]="Struct",e[e.Event=23]="Event",e[e.Operator=24]="Operator",e[e.TypeParameter=25]="TypeParameter"}(re||(re={})),function(e){e[e.Deprecated=1]="Deprecated"}(ie||(ie={})),function(e){e[e.Hidden=0]="Hidden",e[e.Blink=1]="Blink",e[e.Smooth=2]="Smooth",e[e.Phase=3]="Phase",e[e.Expand=4]="Expand",e[e.Solid=5]="Solid"}(se||(se={})),function(e){e[e.Line=1]="Line",e[e.Block=2]="Block",e[e.Underline=3]="Underline",e[e.LineThin=4]="LineThin",e[e.BlockOutline=5]="BlockOutline",e[e.UnderlineThin=6]="UnderlineThin"}(oe||(oe={})),function(e){e[e.AlwaysGrowsWhenTypingAtEdges=0]="AlwaysGrowsWhenTypingAtEdges",e[e.NeverGrowsWhenTypingAtEdges=1]="NeverGrowsWhenTypingAtEdges",e[e.GrowsOnlyWhenTypingBefore=2]="GrowsOnlyWhenTypingBefore",e[e.GrowsOnlyWhenTypingAfter=3]="GrowsOnlyWhenTypingAfter"}(ae||(ae={})),function(e){e[e.None=0]="None",e[e.Same=1]="Same",e[e.Indent=2]="Indent",e[e.DeepIndent=3]="DeepIndent"}(le||(le={}));class fe{static{this.CtrlCmd=2048}static{this.Shift=1024}static{this.Alt=512}static{this.WinCtrl=256}static chord(e,t){return function(e,t){return(e|(65535&t)<<16>>>0)>>>0}(e,t)}}function me(){return{editor:void 0,languages:void 0,CancellationTokenSource:r.Qi,Emitter:i.vl,KeyCode:P,KeyMod:fe,Position:he.y,Range:ue.Q,Selection:de.L,SelectionDirection:ee,MarkerSeverity:V,MarkerTag:z,Uri:ce.r,Token:ge.ou}}},5196:(e,t,n)=>{"use strict";n.r(t),n.d(t,{BaseEditorSimpleWorker:()=>Pe,EditorSimpleWorker:()=>Ve,create:()=>ze});class r{constructor(e,t,n,r){this.originalStart=e,this.originalLength=t,this.modifiedStart=n,this.modifiedLength=r}getOriginalEnd(){return this.originalStart+this.originalLength}getModifiedEnd(){return this.modifiedStart+this.modifiedLength}}var i=n(5600);class s{constructor(e){this.source=e}getElements(){const e=this.source,t=new Int32Array(e.length);for(let n=0,r=e.length;n0||this.m_modifiedCount>0)&&this.m_changes.push(new r(this.m_originalStart,this.m_originalCount,this.m_modifiedStart,this.m_modifiedCount)),this.m_originalCount=0,this.m_modifiedCount=0,this.m_originalStart=1073741824,this.m_modifiedStart=1073741824}AddOriginalElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_originalCount++}AddModifiedElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_modifiedCount++}getChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes}getReverseChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes.reverse(),this.m_changes}}class h{constructor(e,t,n=null){this.ContinueProcessingPredicate=n,this._originalSequence=e,this._modifiedSequence=t;const[r,i,s]=h._getElements(e),[o,a,l]=h._getElements(t);this._hasStrings=s&&l,this._originalStringElements=r,this._originalElementsOrHash=i,this._modifiedStringElements=o,this._modifiedElementsOrHash=a,this.m_forwardHistory=[],this.m_reverseHistory=[]}static _isStringArray(e){return e.length>0&&"string"===typeof e[0]}static _getElements(e){const t=e.getElements();if(h._isStringArray(t)){const e=new Int32Array(t.length);for(let n=0,r=t.length;n=e&&i>=n&&this.ElementsAreEqual(t,i);)t--,i--;if(e>t||n>i){let s;return n<=i?(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),s=[new r(e,0,n,i-n+1)]):e<=t?(a.Assert(n===i+1,"modifiedStart should only be one more than modifiedEnd"),s=[new r(e,t-e+1,n,0)]):(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),a.Assert(n===i+1,"modifiedStart should only be one more than modifiedEnd"),s=[]),s}const o=[0],l=[0],c=this.ComputeRecursionPoint(e,t,n,i,o,l,s),h=o[0],u=l[0];if(null!==c)return c;if(!s[0]){const o=this.ComputeDiffRecursive(e,h,n,u,s);let a=[];return a=s[0]?[new r(h+1,t-(h+1)+1,u+1,i-(u+1)+1)]:this.ComputeDiffRecursive(h+1,t,u+1,i,s),this.ConcatenateChanges(o,a)}return[new r(e,t-e+1,n,i-n+1)]}WALKTRACE(e,t,n,i,s,o,a,l,h,u,d,g,f,m,p,b,_,k){let v=null,C=null,y=new c,L=t,w=n,S=f[0]-b[0]-i,x=-1073741824,E=this.m_forwardHistory.length-1;do{const t=S+e;t===L||t=0&&(e=(h=this.m_forwardHistory[E])[0],L=1,w=h.length-1)}while(--E>=-1);if(v=y.getReverseChanges(),k[0]){let e=f[0]+1,t=b[0]+1;if(null!==v&&v.length>0){const n=v[v.length-1];e=Math.max(e,n.getOriginalEnd()),t=Math.max(t,n.getModifiedEnd())}C=[new r(e,g-e+1,t,p-t+1)]}else{y=new c,L=o,w=a,S=f[0]-b[0]-l,x=1073741824,E=_?this.m_reverseHistory.length-1:this.m_reverseHistory.length-2;do{const e=S+s;e===L||e=u[e+1]?(m=(d=u[e+1]-1)-S-l,d>x&&y.MarkNextChange(),x=d+1,y.AddOriginalElement(d+1,m+1),S=e+1-s):(m=(d=u[e-1])-S-l,d>x&&y.MarkNextChange(),x=d,y.AddModifiedElement(d+1,m+1),S=e-1-s),E>=0&&(s=(u=this.m_reverseHistory[E])[0],L=1,w=u.length-1)}while(--E>=-1);C=y.getChanges()}return this.ConcatenateChanges(v,C)}ComputeRecursionPoint(e,t,n,i,s,o,a){let c=0,h=0,u=0,d=0,g=0,f=0;e--,n--,s[0]=0,o[0]=0,this.m_forwardHistory=[],this.m_reverseHistory=[];const m=t-e+(i-n),p=m+1,b=new Int32Array(p),_=new Int32Array(p),k=i-n,v=t-e,C=e-n,y=t-i,L=(v-k)%2===0;b[k]=e,_[v]=t,a[0]=!1;for(let w=1;w<=m/2+1;w++){let m=0,S=0;u=this.ClipDiagonalBound(k-w,w,k,p),d=this.ClipDiagonalBound(k+w,w,k,p);for(let e=u;e<=d;e+=2){c=e===u||em+S&&(m=c,S=h),!L&&Math.abs(e-v)<=w-1&&c>=_[e])return s[0]=c,o[0]=h,n<=_[e]&&w<=1448?this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a):null}const x=(m-e+(S-n)-w)/2;if(null!==this.ContinueProcessingPredicate&&!this.ContinueProcessingPredicate(m,x))return a[0]=!0,s[0]=m,o[0]=S,x>0&&w<=1448?this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a):(e++,n++,[new r(e,t-e+1,n,i-n+1)]);g=this.ClipDiagonalBound(v-w,w,v,p),f=this.ClipDiagonalBound(v+w,w,v,p);for(let r=g;r<=f;r+=2){c=r===g||r=_[r+1]?_[r+1]-1:_[r-1],h=c-(r-v)-y;const l=c;for(;c>e&&h>n&&this.ElementsAreEqual(c,h);)c--,h--;if(_[r]=c,L&&Math.abs(r-k)<=w&&c<=b[r])return s[0]=c,o[0]=h,l>=b[r]&&w<=1448?this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a):null}if(w<=1447){let e=new Int32Array(d-u+2);e[0]=k-u+1,l.Copy2(b,u,e,1,d-u+1),this.m_forwardHistory.push(e),e=new Int32Array(f-g+2),e[0]=v-g+1,l.Copy2(_,g,e,1,f-g+1),this.m_reverseHistory.push(e)}}return this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a)}PrettifyChanges(e){for(let t=0;t0,o=n.modifiedLength>0;for(;n.originalStart+n.originalLength=0;t--){const n=e[t];let r=0,i=0;if(t>0){const n=e[t-1];r=n.originalStart+n.originalLength,i=n.modifiedStart+n.modifiedLength}const s=n.originalLength>0,o=n.modifiedLength>0;let a=0,l=this._boundaryScore(n.originalStart,n.originalLength,n.modifiedStart,n.modifiedLength);for(let e=1;;e++){const t=n.originalStart-e,c=n.modifiedStart-e;if(tl&&(l=h,a=e)}n.originalStart-=a,n.modifiedStart-=a;const c=[null];t>0&&this.ChangesOverlap(e[t-1],e[t],c)&&(e[t-1]=c[0],e.splice(t,1),t++)}if(this._hasStrings)for(let t=1,n=e.length;t0&&t>a&&(a=t,l=h,c=e)}return a>0?[l,c]:null}_contiguousSequenceScore(e,t,n){let r=0;for(let i=0;i=this._originalElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._originalStringElements[e])}_OriginalRegionIsBoundary(e,t){if(this._OriginalIsBoundary(e)||this._OriginalIsBoundary(e-1))return!0;if(t>0){const n=e+t;if(this._OriginalIsBoundary(n-1)||this._OriginalIsBoundary(n))return!0}return!1}_ModifiedIsBoundary(e){return e<=0||e>=this._modifiedElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._modifiedStringElements[e])}_ModifiedRegionIsBoundary(e,t){if(this._ModifiedIsBoundary(e)||this._ModifiedIsBoundary(e-1))return!0;if(t>0){const n=e+t;if(this._ModifiedIsBoundary(n-1)||this._ModifiedIsBoundary(n))return!0}return!1}_boundaryScore(e,t,n,r){return(this._OriginalRegionIsBoundary(e,t)?1:0)+(this._ModifiedRegionIsBoundary(n,r)?1:0)}ConcatenateChanges(e,t){const n=[];if(0===e.length||0===t.length)return t.length>0?t:e;if(this.ChangesOverlap(e[e.length-1],t[0],n)){const r=new Array(e.length+t.length-1);return l.Copy(e,0,r,0,e.length-1),r[e.length-1]=n[0],l.Copy(t,1,r,e.length,t.length-1),r}{const n=new Array(e.length+t.length);return l.Copy(e,0,n,0,e.length),l.Copy(t,0,n,e.length,t.length),n}}ChangesOverlap(e,t,n){if(a.Assert(e.originalStart<=t.originalStart,"Left change is not less than or equal to right change"),a.Assert(e.modifiedStart<=t.modifiedStart,"Left change is not less than or equal to right change"),e.originalStart+e.originalLength>=t.originalStart||e.modifiedStart+e.modifiedLength>=t.modifiedStart){const i=e.originalStart;let s=e.originalLength;const o=e.modifiedStart;let a=e.modifiedLength;return e.originalStart+e.originalLength>=t.originalStart&&(s=t.originalStart+t.originalLength-e.originalStart),e.modifiedStart+e.modifiedLength>=t.modifiedStart&&(a=t.modifiedStart+t.modifiedLength-e.modifiedStart),n[0]=new r(i,s,o,a),!0}return n[0]=null,!1}ClipDiagonalBound(e,t,n,r){if(e>=0&&et&&(t=s),r>n&&(n=r),o>n&&(n=o)}t++,n++;const r=new g(n,t,0);for(let i=0,s=e.length;i=this._maxCharCode?0:this._states.get(e,t)}}let m=null;let p=null;class b{static _createLink(e,t,n,r,i){let s=i-1;do{const n=t.charCodeAt(s);if(2!==e.get(n))break;s--}while(s>r);if(r>0){const e=t.charCodeAt(r-1),n=t.charCodeAt(s);(40===e&&41===n||91===e&&93===n||123===e&&125===n)&&s--}return{range:{startLineNumber:n,startColumn:r+1,endLineNumber:n,endColumn:s+2},url:t.substring(r,s+1)}}static computeLinks(e,t=function(){return null===m&&(m=new f([[1,104,2],[1,72,2],[1,102,6],[1,70,6],[2,116,3],[2,84,3],[3,116,4],[3,84,4],[4,112,5],[4,80,5],[5,115,9],[5,83,9],[5,58,10],[6,105,7],[6,73,7],[7,108,8],[7,76,8],[8,101,9],[8,69,9],[9,58,10],[10,47,11],[11,47,12]])),m}()){const n=function(){if(null===p){p=new d.V(0);const e=" \t<>'\"\u3001\u3002\uff61\uff64\uff0c\uff0e\uff1a\uff1b\u2018\u3008\u300c\u300e\u3014\uff08\uff3b\uff5b\uff62\uff63\uff5d\uff3d\uff09\u3015\u300f\u300d\u3009\u2019\uff40\uff5e\u2026";for(let n=0;n=0?(r+=n?1:-1,r<0?r=e.length-1:r%=e.length,e[r]):null}}var k=n(4272),v=n(718),C=n(8381),y=n(4855);class L{constructor(e,t,n){this.changes=e,this.moves=t,this.hitTimeout=n}}class w{constructor(e,t){this.lineRangeMapping=e,this.changes=t}}var S=n(4383),x=n(6571),E=n(3069),N=n(6782),T=n(4444);n(973);class A{constructor(e,t){this.range=e,this.text=t}toSingleEditOperation(){return{range:this.range,text:this.text}}}class I{static inverse(e,t,n){const r=[];let i=1,s=1;for(const a of e){const e=new I(new x.M(i,a.original.startLineNumber),new x.M(s,a.modified.startLineNumber));e.modified.isEmpty||r.push(e),i=a.original.endLineNumberExclusive,s=a.modified.endLineNumberExclusive}const o=new I(new x.M(i,t+1),new x.M(s,n+1));return o.modified.isEmpty||r.push(o),r}static clip(e,t,n){const r=[];for(const i of e){const e=i.original.intersect(t),s=i.modified.intersect(n);e&&!e.isEmpty&&s&&!s.isEmpty&&r.push(new I(e,s))}return r}constructor(e,t){this.original=e,this.modified=t}toString(){return`{${this.original.toString()}->${this.modified.toString()}}`}flip(){return new I(this.modified,this.original)}join(e){return new I(this.original.join(e.original),this.modified.join(e.modified))}toRangeMapping(){const e=this.original.toInclusiveRange(),t=this.modified.toInclusiveRange();if(e&&t)return new D(e,t);if(1===this.original.startLineNumber||1===this.modified.startLineNumber){if(1!==this.modified.startLineNumber||1!==this.original.startLineNumber)throw new S.D7("not a valid diff");return new D(new u.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new u.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1))}return new D(new u.Q(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),new u.Q(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER))}toRangeMapping2(e,t){if(M(this.original.endLineNumberExclusive,e)&&M(this.modified.endLineNumberExclusive,t))return new D(new u.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new u.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1));if(!this.original.isEmpty&&!this.modified.isEmpty)return new D(u.Q.fromPositions(new E.y(this.original.startLineNumber,1),O(new E.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),u.Q.fromPositions(new E.y(this.modified.startLineNumber,1),O(new E.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));if(this.original.startLineNumber>1&&this.modified.startLineNumber>1)return new D(u.Q.fromPositions(O(new E.y(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER),e),O(new E.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),u.Q.fromPositions(O(new E.y(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER),t),O(new E.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));throw new S.D7}}function O(e,t){if(e.lineNumber<1)return new E.y(1,1);if(e.lineNumber>t.length)return new E.y(t.length,t[t.length-1].length+1);const n=t[e.lineNumber-1];return e.column>n.length+1?new E.y(e.lineNumber,n.length+1):e}function M(e,t){return e>=1&&e<=t.length}class R extends I{static fromRangeMappings(e){const t=x.M.join(e.map((e=>x.M.fromRangeInclusive(e.originalRange)))),n=x.M.join(e.map((e=>x.M.fromRangeInclusive(e.modifiedRange))));return new R(t,n,e)}constructor(e,t,n){super(e,t),this.innerChanges=n}flip(){return new R(this.modified,this.original,this.innerChanges?.map((e=>e.flip())))}withInnerChangesFromLineRanges(){return new R(this.original,this.modified,[this.toRangeMapping()])}}class D{static assertSorted(e){for(let t=1;t${this.modifiedRange.toString()}}`}flip(){return new D(this.modifiedRange,this.originalRange)}toTextEdit(e){const t=e.getValueOfRange(this.modifiedRange);return new A(this.originalRange,t)}}var B=n(1508);class F{computeDiff(e,t,n){const r=new W(e,t,{maxComputationTime:n.maxComputationTimeMs,shouldIgnoreTrimWhitespace:n.ignoreTrimWhitespace,shouldComputeCharChanges:!0,shouldMakePrettyDiff:!0,shouldPostProcessCharChanges:!0}).computeDiff(),i=[];let s=null;for(const o of r.changes){let e,t;e=0===o.originalEndLineNumber?new x.M(o.originalStartLineNumber+1,o.originalStartLineNumber+1):new x.M(o.originalStartLineNumber,o.originalEndLineNumber+1),t=0===o.modifiedEndLineNumber?new x.M(o.modifiedStartLineNumber+1,o.modifiedStartLineNumber+1):new x.M(o.modifiedStartLineNumber,o.modifiedEndLineNumber+1);let n=new R(e,t,o.charChanges?.map((e=>new D(new u.Q(e.originalStartLineNumber,e.originalStartColumn,e.originalEndLineNumber,e.originalEndColumn),new u.Q(e.modifiedStartLineNumber,e.modifiedStartColumn,e.modifiedEndLineNumber,e.modifiedEndColumn)))));s&&(s.modified.endLineNumberExclusive!==n.modified.startLineNumber&&s.original.endLineNumberExclusive!==n.original.startLineNumber||(n=new R(s.original.join(n.original),s.modified.join(n.modified),s.innerChanges&&n.innerChanges?s.innerChanges.concat(n.innerChanges):void 0),i.pop())),i.push(n),s=n}return(0,N.Ft)((()=>(0,N.Xo)(i,((e,t)=>t.original.startLineNumber-e.original.endLineNumberExclusive===t.modified.startLineNumber-e.modified.endLineNumberExclusive&&e.original.endLineNumberExclusive(10===e?"\\n":String.fromCharCode(e))+`-(${this._lineNumbers[t]},${this._columns[t]})`)).join(", ")+"]"}_assertIndex(e,t){if(e<0||e>=t.length)throw new Error("Illegal index")}getElements(){return this._charCodes}getStartLineNumber(e){return e>0&&e===this._lineNumbers.length?this.getEndLineNumber(e-1):(this._assertIndex(e,this._lineNumbers),this._lineNumbers[e])}getEndLineNumber(e){return-1===e?this.getStartLineNumber(e+1):(this._assertIndex(e,this._lineNumbers),10===this._charCodes[e]?this._lineNumbers[e]+1:this._lineNumbers[e])}getStartColumn(e){return e>0&&e===this._columns.length?this.getEndColumn(e-1):(this._assertIndex(e,this._columns),this._columns[e])}getEndColumn(e){return-1===e?this.getStartColumn(e+1):(this._assertIndex(e,this._columns),10===this._charCodes[e]?1:this._columns[e]+1)}}class j{constructor(e,t,n,r,i,s,o,a){this.originalStartLineNumber=e,this.originalStartColumn=t,this.originalEndLineNumber=n,this.originalEndColumn=r,this.modifiedStartLineNumber=i,this.modifiedStartColumn=s,this.modifiedEndLineNumber=o,this.modifiedEndColumn=a}static createFromDiffChange(e,t,n){const r=t.getStartLineNumber(e.originalStart),i=t.getStartColumn(e.originalStart),s=t.getEndLineNumber(e.originalStart+e.originalLength-1),o=t.getEndColumn(e.originalStart+e.originalLength-1),a=n.getStartLineNumber(e.modifiedStart),l=n.getStartColumn(e.modifiedStart),c=n.getEndLineNumber(e.modifiedStart+e.modifiedLength-1),h=n.getEndColumn(e.modifiedStart+e.modifiedLength-1);return new j(r,i,s,o,a,l,c,h)}}class q{constructor(e,t,n,r,i){this.originalStartLineNumber=e,this.originalEndLineNumber=t,this.modifiedStartLineNumber=n,this.modifiedEndLineNumber=r,this.charChanges=i}static createFromDiffResult(e,t,n,r,i,s,o){let a,l,c,h,u;if(0===t.originalLength?(a=n.getStartLineNumber(t.originalStart)-1,l=0):(a=n.getStartLineNumber(t.originalStart),l=n.getEndLineNumber(t.originalStart+t.originalLength-1)),0===t.modifiedLength?(c=r.getStartLineNumber(t.modifiedStart)-1,h=0):(c=r.getStartLineNumber(t.modifiedStart),h=r.getEndLineNumber(t.modifiedStart+t.modifiedLength-1)),s&&t.originalLength>0&&t.originalLength<20&&t.modifiedLength>0&&t.modifiedLength<20&&i()){const s=n.createCharSequence(e,t.originalStart,t.originalStart+t.originalLength-1),a=r.createCharSequence(e,t.modifiedStart,t.modifiedStart+t.modifiedLength-1);if(s.getElements().length>0&&a.getElements().length>0){let e=P(s,a,i,!0).changes;o&&(e=function(e){if(e.length<=1)return e;const t=[e[0]];let n=t[0];for(let r=1,i=e.length;r1&&o>1;){if(e.charCodeAt(n-2)!==t.charCodeAt(o-2))break;n--,o--}(n>1||o>1)&&this._pushTrimWhitespaceCharChange(r,i+1,1,n,s+1,1,o)}{let n=$(e,1),o=$(t,1);const a=e.length+1,l=t.length+1;for(;n!0;const t=Date.now();return()=>Date.now()-t{n.push(Q.fromOffsetPairs(e?e.getEndExclusives():J.zero,r?r.getStarts():new J(t,(e?e.seq2Range.endExclusive-e.seq1Range.endExclusive:0)+t)))})),n}static fromOffsetPairs(e,t){return new Q(new T.L(e.offset1,t.offset1),new T.L(e.offset2,t.offset2))}static assertSorted(e){let t;for(const n of e){if(t&&!(t.seq1Range.endExclusive<=n.seq1Range.start&&t.seq2Range.endExclusive<=n.seq2Range.start))throw new S.D7("Sequence diffs must be sorted");t=n}}constructor(e,t){this.seq1Range=e,this.seq2Range=t}swap(){return new Q(this.seq2Range,this.seq1Range)}toString(){return`${this.seq1Range} <-> ${this.seq2Range}`}join(e){return new Q(this.seq1Range.join(e.seq1Range),this.seq2Range.join(e.seq2Range))}delta(e){return 0===e?this:new Q(this.seq1Range.delta(e),this.seq2Range.delta(e))}deltaStart(e){return 0===e?this:new Q(this.seq1Range.deltaStart(e),this.seq2Range.deltaStart(e))}deltaEnd(e){return 0===e?this:new Q(this.seq1Range.deltaEnd(e),this.seq2Range.deltaEnd(e))}intersect(e){const t=this.seq1Range.intersect(e.seq1Range),n=this.seq2Range.intersect(e.seq2Range);if(t&&n)return new Q(t,n)}getStarts(){return new J(this.seq1Range.start,this.seq2Range.start)}getEndExclusives(){return new J(this.seq1Range.endExclusive,this.seq2Range.endExclusive)}}class J{static{this.zero=new J(0,0)}static{this.max=new J(Number.MAX_SAFE_INTEGER,Number.MAX_SAFE_INTEGER)}constructor(e,t){this.offset1=e,this.offset2=t}toString(){return`${this.offset1} <-> ${this.offset2}`}delta(e){return 0===e?this:new J(this.offset1+e,this.offset2+e)}equals(e){return this.offset1===e.offset1&&this.offset2===e.offset2}}class X{static{this.instance=new X}isValid(){return!0}}class Y{constructor(e){if(this.timeout=e,this.startTime=Date.now(),this.valid=!0,e<=0)throw new S.D7("timeout must be positive")}isValid(){return!(Date.now()-this.startTime0&&a>0&&3===s.get(g-1,a-1)&&(h+=o.get(g-1,a-1)),h+=r?r(g,a):1):h=-1;const u=Math.max(l,c,h);if(u===h){const e=g>0&&a>0?o.get(g-1,a-1):0;o.set(g,a,e+1),s.set(g,a,3)}else u===l?(o.set(g,a,0),s.set(g,a,1)):u===c&&(o.set(g,a,0),s.set(g,a,2));i.set(g,a,u)}const a=[];let l=e.length,c=t.length;function h(e,t){e+1===l&&t+1===c||a.push(new Q(new T.L(e+1,l),new T.L(t+1,c))),l=e,c=t}let u=e.length-1,d=t.length-1;for(;u>=0&&d>=0;)3===s.get(u,d)?(h(u,d),u--,d--):1===s.get(u,d)?u--:d--;return h(-1,-1),a.reverse(),new G(a,!1)}}class re{compute(e,t,n=X.instance){if(0===e.length||0===t.length)return G.trivial(e,t);const r=e,i=t;function s(e,t){for(;er.length||d>i.length)continue;const g=s(u,d);a.set(c,g);const f=u===o?l.get(c+1):l.get(c-1);if(l.set(c,g!==u?new ie(f,u,d,g-u):f),a.get(c)===r.length&&a.get(c)-c===i.length)break e}}let h=l.get(c);const u=[];let d=r.length,g=i.length;for(;;){const e=h?h.x+h.length:0,t=h?h.y+h.length:0;if(e===d&&t===g||u.push(new Q(new T.L(e,d),new T.L(t,g))),!h)break;d=h.x,g=h.y,h=h.prev}return u.reverse(),new G(u,!1)}}class ie{constructor(e,t,n,r){this.prev=e,this.x=t,this.y=n,this.length=r}}class se{constructor(){this.positiveArr=new Int32Array(10),this.negativeArr=new Int32Array(10)}get(e){return e<0?(e=-e-1,this.negativeArr[e]):this.positiveArr[e]}set(e,t){if(e<0){if((e=-e-1)>=this.negativeArr.length){const e=this.negativeArr;this.negativeArr=new Int32Array(2*e.length),this.negativeArr.set(e)}this.negativeArr[e]=t}else{if(e>=this.positiveArr.length){const e=this.positiveArr;this.positiveArr=new Int32Array(2*e.length),this.positiveArr.set(e)}this.positiveArr[e]=t}}}class oe{constructor(){this.positiveArr=[],this.negativeArr=[]}get(e){return e<0?(e=-e-1,this.negativeArr[e]):this.positiveArr[e]}set(e,t){e<0?(e=-e-1,this.negativeArr[e]=t):this.positiveArr[e]=t}}var ae=n(6041),le=n(4320);class ce{constructor(e,t,n){this.lines=e,this.range=t,this.considerWhitespaceChanges=n,this.elements=[],this.firstElementOffsetByLineIdx=[],this.lineStartOffsets=[],this.trimmedWsLengthsByLineIdx=[],this.firstElementOffsetByLineIdx.push(0);for(let r=this.range.startLineNumber;r<=this.range.endLineNumber;r++){let t=e[r-1],i=0;r===this.range.startLineNumber&&this.range.startColumn>1&&(i=this.range.startColumn-1,t=t.substring(i)),this.lineStartOffsets.push(i);let s=0;if(!n){const e=t.trimStart();s=t.length-e.length,t=e.trimEnd()}this.trimmedWsLengthsByLineIdx.push(s);const o=r===this.range.endLineNumber?Math.min(this.range.endColumn-1-i-s,t.length):t.length;for(let e=0;eString.fromCharCode(e))).join("")}getElement(e){return this.elements[e]}get length(){return this.elements.length}getBoundaryScore(e){const t=ge(e>0?this.elements[e-1]:-1),n=ge(et<=e)),r=e-this.firstElementOffsetByLineIdx[n];return new E.y(this.range.startLineNumber+n,1+this.lineStartOffsets[n]+r+(0===r&&"left"===t?0:this.trimmedWsLengthsByLineIdx[n]))}translateRange(e){const t=this.translateOffset(e.start,"right"),n=this.translateOffset(e.endExclusive,"left");return n.isBefore(t)?u.Q.fromPositions(n,n):u.Q.fromPositions(t,n)}findWordContaining(e){if(e<0||e>=this.elements.length)return;if(!he(this.elements[e]))return;let t=e;for(;t>0&&he(this.elements[t-1]);)t--;let n=e;for(;nt<=e.start))??0,n=(0,ae.XP)(this.firstElementOffsetByLineIdx,(t=>e.endExclusive<=t))??this.elements.length;return new T.L(t,n)}}function he(e){return e>=97&&e<=122||e>=65&&e<=90||e>=48&&e<=57}const ue={0:0,1:0,2:0,3:10,4:2,5:30,6:3,7:10,8:10};function de(e){return ue[e]}function ge(e){return 10===e?8:13===e?7:ee(e)?6:e>=97&&e<=122?0:e>=65&&e<=90?1:e>=48&&e<=57?2:-1===e?3:44===e||59===e?5:4}function fe(e,t,n,r,i,s){let{moves:o,excludedChanges:a}=function(e,t,n,r){const i=[],s=e.filter((e=>e.modified.isEmpty&&e.original.length>=3)).map((e=>new te(e.original,t,e))),o=new Set(e.filter((e=>e.original.isEmpty&&e.modified.length>=3)).map((e=>new te(e.modified,n,e)))),a=new Set;for(const l of s){let e,t=-1;for(const n of o){const r=l.computeSimilarity(n);r>t&&(t=r,e=n)}if(t>.9&&e&&(o.delete(e),i.push(new I(l.range,e.range)),a.add(l.source),a.add(e.source)),!r.isValid())return{moves:i,excludedChanges:a}}return{moves:i,excludedChanges:a}}(e,t,n,s);if(!s.isValid())return[];const l=function(e,t,n,r,i,s){const o=[],a=new le.db;for(const d of e)for(let e=d.original.startLineNumber;ee.modified.startLineNumber),K.U9));for(const d of e){let e=[];for(let t=d.modified.startLineNumber;t{for(const r of e)if(r.originalLineRange.endLineNumberExclusive+1===t.endLineNumberExclusive&&r.modifiedLineRange.endLineNumberExclusive+1===i.endLineNumberExclusive)return r.originalLineRange=new x.M(r.originalLineRange.startLineNumber,t.endLineNumberExclusive),r.modifiedLineRange=new x.M(r.modifiedLineRange.startLineNumber,i.endLineNumberExclusive),void s.push(r);const n={modifiedLineRange:i,originalLineRange:t};l.push(n),s.push(n)})),e=s}if(!s.isValid())return[]}l.sort((0,K.Hw)((0,K.VE)((e=>e.modifiedLineRange.length),K.U9)));const c=new x.S,h=new x.S;for(const d of l){const e=d.modifiedLineRange.startLineNumber-d.originalLineRange.startLineNumber,t=c.subtractFrom(d.modifiedLineRange),n=h.subtractFrom(d.originalLineRange).getWithDelta(e),r=t.getIntersection(n);for(const i of r.ranges){if(i.length<3)continue;const t=i,n=i.delta(-e);o.push(new I(n,t)),c.addRange(t),h.addRange(n)}}o.sort((0,K.VE)((e=>e.original.startLineNumber),K.U9));const u=new ae.vJ(e);for(let d=0;de.original.startLineNumber<=t.original.startLineNumber)),a=(0,ae.lx)(e,(e=>e.modified.startLineNumber<=t.modified.startLineNumber)),l=Math.max(t.original.startLineNumber-n.original.startLineNumber,t.modified.startLineNumber-a.modified.startLineNumber),g=u.findLastMonotonous((e=>e.original.startLineNumbere.modified.startLineNumberr.length||n>i.length)break;if(c.contains(n)||h.contains(e))break;if(!me(r[e-1],i[n-1],s))break}for(p>0&&(h.addRange(new x.M(t.original.startLineNumber-p,t.original.startLineNumber)),c.addRange(new x.M(t.modified.startLineNumber-p,t.modified.startLineNumber))),b=0;br.length||n>i.length)break;if(c.contains(n)||h.contains(e))break;if(!me(r[e-1],i[n-1],s))break}b>0&&(h.addRange(new x.M(t.original.endLineNumberExclusive,t.original.endLineNumberExclusive+b)),c.addRange(new x.M(t.modified.endLineNumberExclusive,t.modified.endLineNumberExclusive+b))),(p>0||b>0)&&(o[d]=new I(new x.M(t.original.startLineNumber-p,t.original.endLineNumberExclusive+b),new x.M(t.modified.startLineNumber-p,t.modified.endLineNumberExclusive+b)))}return o}(e.filter((e=>!a.has(e))),r,i,t,n,s);return(0,K.E4)(o,l),o=function(e){if(0===e.length)return e;e.sort((0,K.VE)((e=>e.original.startLineNumber),K.U9));const t=[e[0]];for(let n=1;n=0&&o>=0&&s+o<=2?t[t.length-1]=r.join(i):t.push(i)}return t}(o),o=o.filter((e=>{const n=e.original.toOffsetRange().slice(t).map((e=>e.trim()));return n.join("\n").length>=15&&function(e,t){let n=0;for(const r of e)t(r)&&n++;return n}(n,(e=>e.length>=2))>=2})),o=function(e,t){const n=new ae.vJ(e);return t=t.filter((t=>(n.findLastMonotonous((e=>e.original.startLineNumbere.modified.startLineNumber300&&t.length>300)return!1;const r=(new re).compute(new ce([e],new u.Q(1,1,1,e.length),!1),new ce([t],new u.Q(1,1,1,t.length),!1),n);let i=0;const s=Q.invert(r.diffs,e.length);for(const a of s)a.seq1Range.forEach((t=>{ee(e.charCodeAt(t))||i++}));const o=function(t){let n=0;for(let r=0;rt.length?e:t);return i/o>.6&&o>10}function pe(e,t,n){let r=n;return r=be(e,t,r),r=be(e,t,r),r=function(e,t,n){if(!e.getBoundaryScore||!t.getBoundaryScore)return n;for(let r=0;r0?n[r-1]:void 0,s=n[r],o=r+10&&(o=o.delta(a))}i.push(o)}return r.length>0&&i.push(r[r.length-1]),i}function _e(e,t,n,r,i){let s=1;for(;e.seq1Range.start-s>=r.start&&e.seq2Range.start-s>=i.start&&n.isStronglyEqual(e.seq2Range.start-s,e.seq2Range.endExclusive-s)&&s<100;)s++;s--;let o=0;for(;e.seq1Range.start+ol&&(l=o,a=c)}return e.delta(a)}class ke{constructor(e,t){this.trimmedHash=e,this.lines=t}getElement(e){return this.trimmedHash[e]}get length(){return this.trimmedHash.length}getBoundaryScore(e){return 1e3-((0===e?0:ve(this.lines[e-1]))+(e===this.lines.length?0:ve(this.lines[e])))}getText(e){return this.lines.slice(e.start,e.endExclusive).join("\n")}isStronglyEqual(e,t){return this.lines[e]===this.lines[t]}}function ve(e){let t=0;for(;te===t)))return new L([],[],!1);if(1===e.length&&0===e[0].length||1===t.length&&0===t[0].length)return new L([new R(new x.M(1,e.length+1),new x.M(1,t.length+1),[new D(new u.Q(1,1,e.length,e[e.length-1].length+1),new u.Q(1,1,t.length,t[t.length-1].length+1))])],[],!1);const r=0===n.maxComputationTimeMs?X.instance:new Y(n.maxComputationTimeMs),i=!n.ignoreTrimWhitespace,s=new Map;function o(e){let t=s.get(e);return void 0===t&&(t=s.size,s.set(e,t)),t}const a=e.map((e=>o(e.trim()))),l=t.map((e=>o(e.trim()))),c=new ke(a,e),h=new ke(l,t),d=(()=>c.length+h.length<1700?this.dynamicProgrammingDiffing.compute(c,h,r,((n,r)=>e[n]===t[r]?0===t[r].length?.1:1+Math.log(1+t[r].length):.99)):this.myersDiffingAlgorithm.compute(c,h,r))();let g=d.diffs,f=d.hitTimeout;g=pe(c,h,g),g=function(e,t,n){let r=n;if(0===r.length)return r;let i,s=0;do{i=!1;const o=[r[0]];for(let a=1;a5||n.seq1Range.length+n.seq2Range.length>5)}h(c,l)?(i=!0,o[o.length-1]=o[o.length-1].join(l)):o.push(l)}r=o}while(s++<10&&i);return r}(c,0,g);const m=[],p=n=>{if(i)for(let s=0;su.seq1Range.start-b===u.seq2Range.start-_));p(u.seq1Range.start-b),b=u.seq1Range.endExclusive,_=u.seq2Range.endExclusive;const n=this.refineDiff(e,t,u,r,i);n.hitTimeout&&(f=!0);for(const e of n.mappings)m.push(e)}p(e.length-b);const k=ye(m,e,t);let v=[];return n.computeMoves&&(v=this.computeMoves(k,e,t,a,l,r,i)),(0,N.Ft)((()=>{function n(e,t){if(e.lineNumber<1||e.lineNumber>t.length)return!1;const n=t[e.lineNumber-1];return!(e.column<1||e.column>n.length+1)}function r(e,t){return!(e.startLineNumber<1||e.startLineNumber>t.length+1)&&!(e.endLineNumberExclusive<1||e.endLineNumberExclusive>t.length+1)}for(const i of k){if(!i.innerChanges)return!1;for(const r of i.innerChanges){if(!(n(r.modifiedRange.getStartPosition(),t)&&n(r.modifiedRange.getEndPosition(),t)&&n(r.originalRange.getStartPosition(),e)&&n(r.originalRange.getEndPosition(),e)))return!1}if(!r(i.modified,t)||!r(i.original,e))return!1}return!0})),new L(k,v,f)}computeMoves(e,t,n,r,i,s,o){return fe(e,t,n,r,i,s).map((e=>{const r=ye(this.refineDiff(t,n,new Q(e.original.toOffsetRange(),e.modified.toOffsetRange()),s,o).mappings,t,n,!0);return new w(e,r)}))}refineDiff(e,t,n,r,i){var s;const o=(s=n,new I(new x.M(s.seq1Range.start+1,s.seq1Range.endExclusive+1),new x.M(s.seq2Range.start+1,s.seq2Range.endExclusive+1))).toRangeMapping2(e,t),a=new ce(e,o.originalRange,i),l=new ce(t,o.modifiedRange,i),c=a.length+l.length<500?this.dynamicProgrammingDiffing.compute(a,l,r):this.myersDiffingAlgorithm.compute(a,l,r),h=!1;let u=c.diffs;u=pe(a,l,u),u=function(e,t,n){const r=Q.invert(n,e.length),i=[];let s=new J(0,0);function o(n,o){if(n.offset10;){const n=r[0];if(!n.seq1Range.intersects(c.seq1Range)&&!n.seq2Range.intersects(c.seq2Range))break;const i=e.findWordContaining(n.seq1Range.start),s=t.findWordContaining(n.seq2Range.start),o=new Q(i,s),a=o.intersect(n);if(u+=a.seq1Range.length,d+=a.seq2Range.length,c=c.join(o),!(c.seq1Range.endExclusive>=n.seq1Range.endExclusive))break;r.shift()}u+d<2*(c.seq1Range.length+c.seq2Range.length)/3&&i.push(c),s=c.getEndExclusives()}for(;r.length>0;){const e=r.shift();e.seq1Range.isEmpty||(o(e.getStarts(),e),o(e.getEndExclusives().delta(-1),e))}return function(e,t){const n=[];for(;e.length>0||t.length>0;){const r=e[0],i=t[0];let s;s=r&&(!i||r.seq1Range.start0&&n[n.length-1].seq1Range.endExclusive>=s.seq1Range.start?n[n.length-1]=n[n.length-1].join(s):n.push(s)}return n}(n,i)}(a,l,u),u=function(e,t,n){const r=[];for(const i of n){const e=r[r.length-1];e&&(i.seq1Range.start-e.seq1Range.endExclusive<=2||i.seq2Range.start-e.seq2Range.endExclusive<=2)?r[r.length-1]=new Q(e.seq1Range.join(i.seq1Range),e.seq2Range.join(i.seq2Range)):r.push(i)}return r}(0,0,u),u=function(e,t,n){let r=n;if(0===r.length)return r;let i,s=0;do{i=!1;const a=[r[0]];for(let l=1;l5||i.length>500)return!1;const s=e.getText(i).trim();if(s.length>20||s.split(/\r\n|\r|\n/).length>1)return!1;const o=e.countLinesIn(n.seq1Range),a=n.seq1Range.length,l=t.countLinesIn(n.seq2Range),u=n.seq2Range.length,d=e.countLinesIn(r.seq1Range),g=r.seq1Range.length,f=t.countLinesIn(r.seq2Range),m=r.seq2Range.length;function p(e){return Math.min(e,130)}return Math.pow(Math.pow(p(40*o+a),1.5)+Math.pow(p(40*l+u),1.5),1.5)+Math.pow(Math.pow(p(40*d+g),1.5)+Math.pow(p(40*f+m),1.5),1.5)>74184.96480721243}u(h,c)?(i=!0,a[a.length-1]=a[a.length-1].join(c)):a.push(c)}r=a}while(s++<10&&i);const o=[];return(0,K.kj)(r,((t,n,r)=>{let i=n;function s(e){return e.length>0&&e.trim().length<=3&&n.seq1Range.length+n.seq2Range.length>100}const a=e.extendToFullLines(n.seq1Range),l=e.getText(new T.L(a.start,n.seq1Range.start));s(l)&&(i=i.deltaStart(-l.length));const c=e.getText(new T.L(n.seq1Range.endExclusive,a.endExclusive));s(c)&&(i=i.deltaEnd(c.length));const h=Q.fromOffsetPairs(t?t.getEndExclusives():J.zero,r?r.getStarts():J.max),u=i.intersect(h);o.length>0&&u.getStarts().equals(o[o.length-1].getEndExclusives())?o[o.length-1]=o[o.length-1].join(u):o.push(u)})),o}(a,l,u);const d=u.map((e=>new D(a.translateRange(e.seq1Range),l.translateRange(e.seq2Range))));return{mappings:d,hitTimeout:c.hitTimeout}}}function ye(e,t,n,r=!1){const i=[];for(const s of(0,K.n)(e.map((e=>function(e,t,n){let r=0,i=0;1===e.modifiedRange.endColumn&&1===e.originalRange.endColumn&&e.originalRange.startLineNumber+r<=e.originalRange.endLineNumber&&e.modifiedRange.startLineNumber+r<=e.modifiedRange.endLineNumber&&(i=-1);e.modifiedRange.startColumn-1>=n[e.modifiedRange.startLineNumber-1].length&&e.originalRange.startColumn-1>=t[e.originalRange.startLineNumber-1].length&&e.originalRange.startLineNumber<=e.originalRange.endLineNumber+i&&e.modifiedRange.startLineNumber<=e.modifiedRange.endLineNumber+i&&(r=1);const s=new x.M(e.originalRange.startLineNumber+r,e.originalRange.endLineNumber+1+i),o=new x.M(e.modifiedRange.startLineNumber+r,e.modifiedRange.endLineNumber+1+i);return new R(s,o,[e])}(e,t,n))),((e,t)=>e.original.overlapOrTouch(t.original)||e.modified.overlapOrTouch(t.modified)))){const e=s[0],t=s[s.length-1];i.push(new R(e.original.join(t.original),e.modified.join(t.modified),s.map((e=>e.innerChanges[0]))))}return(0,N.Ft)((()=>{if(!r&&i.length>0){if(i[0].modified.startLineNumber!==i[0].original.startLineNumber)return!1;if(n.length-i[i.length-1].modified.endLineNumberExclusive!==t.length-i[i.length-1].original.endLineNumberExclusive)return!1}return(0,N.Xo)(i,((e,t)=>t.original.startLineNumber-e.original.endLineNumberExclusive===t.modified.startLineNumber-e.modified.endLineNumberExclusive&&e.original.endLineNumberExclusivenew F,we=()=>new Ce;var Se=n(146),xe=n(6456),Ee=n(7661);function Ne(e){const t=[];for(const n of e){const e=Number(n);(e||0===e&&""!==n.replace(/\s/g,""))&&t.push(e)}return t}function Te(e,t,n,r){return{red:e/255,blue:n/255,green:t/255,alpha:r}}function Ae(e,t){const n=t.index,r=t[0].length;if(!n)return;const i=e.positionAt(n);return{startLineNumber:i.lineNumber,startColumn:i.column,endLineNumber:i.lineNumber,endColumn:i.column+r}}function Ie(e,t){if(!e)return;const n=Ee.Q1.Format.CSS.parseHex(t);return n?{range:e,color:Te(n.rgba.r,n.rgba.g,n.rgba.b,n.rgba.a)}:void 0}function Oe(e,t,n){if(!e||1!==t.length)return;const r=Ne(t[0].values());return{range:e,color:Te(r[0],r[1],r[2],n?r[3]:1)}}function Me(e,t,n){if(!e||1!==t.length)return;const r=Ne(t[0].values()),i=new Ee.Q1(new Ee.hB(r[0],r[1]/100,r[2]/100,n?r[3]:1));return{range:e,color:Te(i.rgba.r,i.rgba.g,i.rgba.b,i.rgba.a)}}function Re(e,t){return"string"===typeof e?[...e.matchAll(t)]:e.findMatches(t)}function De(e){return e&&"function"===typeof e.getValue&&"function"===typeof e.positionAt?function(e){const t=[],n=Re(e,/\b(rgb|rgba|hsl|hsla)(\([0-9\s,.\%]*\))|(#)([A-Fa-f0-9]{3})\b|(#)([A-Fa-f0-9]{4})\b|(#)([A-Fa-f0-9]{6})\b|(#)([A-Fa-f0-9]{8})\b/gm);if(n.length>0)for(const r of n){const n=r.filter((e=>void 0!==e)),i=n[1],s=n[2];if(!s)continue;let o;if("rgb"===i){const t=/^\(\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*\)$/gm;o=Oe(Ae(e,r),Re(s,t),!1)}else if("rgba"===i){const t=/^\(\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(0[.][0-9]+|[.][0-9]+|[01][.]|[01])\s*\)$/gm;o=Oe(Ae(e,r),Re(s,t),!0)}else if("hsl"===i){const t=/^\(\s*(36[0]|3[0-5][0-9]|[12][0-9][0-9]|[1-9]?[0-9])\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*\)$/gm;o=Me(Ae(e,r),Re(s,t),!1)}else if("hsla"===i){const t=/^\(\s*(36[0]|3[0-5][0-9]|[12][0-9][0-9]|[1-9]?[0-9])\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(0[.][0-9]+|[.][0-9]+|[01][.]|[01])\s*\)$/gm;o=Me(Ae(e,r),Re(s,t),!0)}else"#"===i&&(o=Ie(Ae(e,r),i+s));o&&t.push(o)}return t}(e):[]}var Be=n(6691),Fe=n(796);class Pe{constructor(){this._workerTextModelSyncServer=new Fe.WorkerTextModelSyncServer}dispose(){}_getModel(e){return this._workerTextModelSyncServer.getModel(e)}_getModels(){return this._workerTextModelSyncServer.getModels()}$acceptNewModel(e){this._workerTextModelSyncServer.$acceptNewModel(e)}$acceptModelChanged(e,t){this._workerTextModelSyncServer.$acceptModelChanged(e,t)}$acceptRemovedModel(e){this._workerTextModelSyncServer.$acceptRemovedModel(e)}async $computeUnicodeHighlights(e,t,n){const r=this._getModel(e);return r?y.UnicodeTextModelHighlighter.computeUnicodeHighlights(r,t,n):{ranges:[],hasMore:!1,ambiguousCharacterCount:0,invisibleCharacterCount:0,nonBasicAsciiCharacterCount:0}}async $findSectionHeaders(e,t){const n=this._getModel(e);return n?(0,Be.findSectionHeaders)(n,t):[]}async $computeDiff(e,t,n,r){const i=this._getModel(e),s=this._getModel(t);if(!i||!s)return null;return Ve.computeDiff(i,s,n,r)}static computeDiff(e,t,n,r){const i="advanced"===r?we():Le(),s=e.getLinesContent(),o=t.getLinesContent(),a=i.computeDiff(s,o,n);function l(e){return e.map((e=>[e.original.startLineNumber,e.original.endLineNumberExclusive,e.modified.startLineNumber,e.modified.endLineNumberExclusive,e.innerChanges?.map((e=>[e.originalRange.startLineNumber,e.originalRange.startColumn,e.originalRange.endLineNumber,e.originalRange.endColumn,e.modifiedRange.startLineNumber,e.modifiedRange.startColumn,e.modifiedRange.endLineNumber,e.modifiedRange.endColumn]))]))}return{identical:!(a.changes.length>0)&&this._modelsAreIdentical(e,t),quitEarly:a.hitTimeout,changes:l(a.changes),moves:a.moves.map((e=>[e.lineRangeMapping.original.startLineNumber,e.lineRangeMapping.original.endLineNumberExclusive,e.lineRangeMapping.modified.startLineNumber,e.lineRangeMapping.modified.endLineNumberExclusive,l(e.changes)]))}}static _modelsAreIdentical(e,t){const n=e.getLineCount();if(n!==t.getLineCount())return!1;for(let r=1;r<=n;r++){if(e.getLineContent(r)!==t.getLineContent(r))return!1}return!0}static{this._diffLimit=1e5}async $computeMoreMinimalEdits(e,t,n){const r=this._getModel(e);if(!r)return t;const i=[];let s;t=t.slice(0).sort(((e,t)=>{if(e.range&&t.range)return u.Q.compareRangesUsingStarts(e.range,t.range);return(e.range?0:1)-(t.range?0:1)}));let a=0;for(let o=1;oVe._diffLimit){i.push({range:l,text:c});continue}const t=o(e,c,n),a=r.offsetAt(u.Q.lift(l).getStartPosition());for(const n of t){const e=r.positionAt(a+n.originalStart),t=r.positionAt(a+n.originalStart+n.originalLength),s={text:c.substr(n.modifiedStart,n.modifiedLength),range:{startLineNumber:e.lineNumber,startColumn:e.column,endLineNumber:t.lineNumber,endColumn:t.column}};r.getValueInRange(s.range)!==s.text&&i.push(s)}}return"number"===typeof s&&i.push({eol:s,text:"",range:{startLineNumber:0,startColumn:0,endLineNumber:0,endColumn:0}}),i}async $computeLinks(e){const t=this._getModel(e);return t?function(e){return e&&"function"===typeof e.getLineCount&&"function"===typeof e.getLineContent?b.computeLinks(e):[]}(t):null}async $computeDefaultDocumentColors(e){const t=this._getModel(e);return t?De(t):null}static{this._suggestionsLimit=1e4}async $textualSuggest(e,t,n,r){const i=new C.W,s=new RegExp(n,r),o=new Set;e:for(const a of e){const e=this._getModel(a);if(e)for(const n of e.words(s))if(n!==t&&isNaN(Number(n))&&(o.add(n),o.size>Ve._suggestionsLimit))break e}return{words:Array.from(o),duration:i.elapsed()}}async $computeWordRanges(e,t,n,r){const i=this._getModel(e);if(!i)return Object.create(null);const s=new RegExp(n,r),o=Object.create(null);for(let a=t.startLineNumber;athis._host.$fhr(e,t))),getMirrorModels:()=>this._getModels()};return this._foreignModuleFactory?(this._foreignModule=this._foreignModuleFactory(i,t),Promise.resolve((0,Se.V0)(this._foreignModule))):new Promise(((r,s)=>{const o=e=>{this._foreignModule=e.create(i,t),r((0,Se.V0)(this._foreignModule))};{const t=xe.zl.asBrowserUri(`${e}.js`).toString(!0);n(9204)(`${t}`).then(o).catch(s)}}))}$fmr(e,t){if(!this._foreignModule||"function"!==typeof this._foreignModule[e])return Promise.reject(new Error("Missing requestHandler or method: "+e));try{return Promise.resolve(this._foreignModule[e].apply(this._foreignModule,t))}catch(n){return Promise.reject(n)}}}function ze(e){return new Ve(v.EditorWorkerHost.getChannel(e),null)}"function"===typeof importScripts&&(globalThis.monaco=(0,k.createMonacoBaseAPI)())},920:(e,t,n)=>{"use strict";n.r(t),n.d(t,{IEditorWorkerService:()=>r});const r=(0,n(3591).u1)("editorWorkerService")},718:(e,t,n)=>{"use strict";n.r(t),n.d(t,{EditorWorkerHost:()=>r});class r{static{this.CHANNEL_NAME="editorWorkerHost"}static getChannel(e){return e.getChannel(r.CHANNEL_NAME)}static setChannel(e,t){e.setChannel(r.CHANNEL_NAME,t)}}},6691:(e,t,n)=>{"use strict";n.r(t),n.d(t,{findSectionHeaders:()=>s});const r=new RegExp("\\bMARK:\\s*(.*)$","d"),i=/^-+|-+$/g;function s(e,t){let n=[];if(t.findRegionSectionHeaders&&t.foldingRules?.markers){const r=function(e,t){const n=[],r=e.getLineCount();for(let i=1;i<=r;i++){const r=e.getLineContent(i),s=r.match(t.foldingRules.markers.start);if(s){const e={startLineNumber:i,startColumn:s[0].length+1,endLineNumber:i,endColumn:r.length+1};if(e.endColumn>e.startColumn){const t={range:e,...a(r.substring(s[0].length)),shouldBeInComments:!1};(t.text||t.hasSeparatorLine)&&n.push(t)}}}return n}(e,t);n=n.concat(r)}if(t.findMarkSectionHeaders){const t=function(e){const t=[],n=e.getLineCount();for(let r=1;r<=n;r++){o(e.getLineContent(r),r,t)}return t}(e);n=n.concat(t)}return n}function o(e,t,n){r.lastIndex=0;const i=r.exec(e);if(i){const e={startLineNumber:t,startColumn:i.indices[1][0]+1,endLineNumber:t,endColumn:i.indices[1][1]+1};if(e.endColumn>e.startColumn){const t={range:e,...a(i[1]),shouldBeInComments:!0};(t.text||t.hasSeparatorLine)&&n.push(t)}}}function a(e){const t=(e=e.trim()).startsWith("-");return{text:e=e.replace(i,""),hasSeparatorLine:t}}},5628:(e,t,n)=>{"use strict";n.r(t),n.d(t,{getIconClasses:()=>d});var r,i=n(6456),s=n(9403),o=n(9400),a=n(3941);!function(e){e[e.FILE=0]="FILE",e[e.FOLDER=1]="FOLDER",e[e.ROOT_FOLDER=2]="ROOT_FOLDER"}(r||(r={}));var l,c,h=n(9493);!function(e){e.isThemeColor=function(e){return e&&"object"===typeof e&&"string"===typeof e.id}}(l||(l={})),function(e){e.iconNameSegment="[A-Za-z0-9]+",e.iconNameExpression="[A-Za-z0-9-]+",e.iconModifierExpression="~[A-Za-z]+",e.iconNameCharacter="[A-Za-z0-9~-]";const t=new RegExp(`^(${e.iconNameExpression})(${e.iconModifierExpression})?$`);function n(e){const r=t.exec(e.id);if(!r)return n(h.W.error);const[,i,s]=r,o=["codicon","codicon-"+i];return s&&o.push("codicon-modifier-"+s.substring(1)),o}e.asClassNameArray=n,e.asClassName=function(e){return n(e).join(" ")},e.asCSSSelector=function(e){return"."+n(e).join(".")},e.isThemeIcon=function(e){return e&&"object"===typeof e&&"string"===typeof e.id&&("undefined"===typeof e.color||l.isThemeColor(e.color))};const r=new RegExp(`^\\$\\((${e.iconNameExpression}(?:${e.iconModifierExpression})?)\\)$`);e.fromString=function(e){const t=r.exec(e);if(!t)return;const[,n]=t;return{id:n}},e.fromId=function(e){return{id:e}},e.modify=function(e,t){let n=e.id;const r=n.lastIndexOf("~");return-1!==r&&(n=n.substring(0,r)),t&&(n=`${n}~${t}`),{id:n}},e.getModifier=function(e){const t=e.id.lastIndexOf("~");if(-1!==t)return e.id.substring(t+1)},e.isEqual=function(e,t){return e.id===t.id&&e.color?.id===t.color?.id}}(c||(c={}));const u=/(?:\/|^)(?:([^\/]+)\/)?([^\/]+)$/;function d(e,t,n,l,h){if(c.isThemeIcon(h))return[`codicon-${h.id}`,"predefined-file-icon"];if(o.r.isUri(h))return[];const d=l===r.ROOT_FOLDER?["rootfolder-icon"]:l===r.FOLDER?["folder-icon"]:["file-icon"];if(n){let o;if(n.scheme===i.ny.data){o=s.B6.parseMetaData(n).get(s.B6.META_DATA_LABEL)}else{const e=n.path.match(u);e?(o=g(e[2].toLowerCase()),e[1]&&d.push(`${g(e[1].toLowerCase())}-name-dir-icon`)):o=g(n.authority.toLowerCase())}if(l===r.ROOT_FOLDER)d.push(`${o}-root-name-folder-icon`);else if(l===r.FOLDER)d.push(`${o}-name-folder-icon`);else{if(o){if(d.push(`${o}-name-file-icon`),d.push("name-file-icon"),o.length<=255){const e=o.split(".");for(let t=1;t{"use strict";n.r(t),n.d(t,{ILanguageFeatureDebounceService:()=>m,LanguageFeatureDebounceService:()=>k});var r=n(5600),i=n(4320);function s(e,t,n){return Math.min(Math.max(e,t),n)}class o{constructor(){this._n=1,this._val=0}update(e){return this._val=this._val+(e-this._val)/this._n,this._n+=1,this._val}get value(){return this._val}}class a{constructor(e){this._n=0,this._val=0,this._values=[],this._index=0,this._sum=0,this._values=new Array(e),this._values.fill(0,0,e)}update(e){const t=this._values[this._index];return this._values[this._index]=e,this._index=(this._index+1)%this._values.length,this._sum-=t,this._sum+=e,this._n=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},f=function(e,t){return function(n,r){t(n,r,e)}};const m=(0,l.u1)("ILanguageFeatureDebounceService");var p;!function(e){const t=new WeakMap;let n=0;e.of=function(e){let r=t.get(e);return void 0===r&&(r=++n,t.set(e,r)),r}}(p||(p={}));class b{constructor(e){this._default=e}get(e){return this._default}update(e,t){return this._default}default(){return this._default}}class _{constructor(e,t,n,r,s,o){this._logService=e,this._name=t,this._registry=n,this._default=r,this._min=s,this._max=o,this._cache=new i.qK(50,.7)}_key(e){return e.id+this._registry.all(e).reduce(((e,t)=>(0,r.sN)(p.of(t),e)),0)}get(e){const t=this._key(e),n=this._cache.get(t);return n?s(n.value,this._min,this._max):this.default()}update(e,t){const n=this._key(e);let r=this._cache.get(n);r||(r=new a(6),this._cache.set(n,r));const i=s(r.update(t),this._min,this._max);return(0,d.v$)(e.uri,"output")||this._logService.trace(`[DEBOUNCE: ${this._name}] for ${e.uri.toString()} is ${i}ms`),i}_overall(){const e=new o;for(const[,t]of this._cache)e.update(t.value);return e.value}default(){return s(0|this._overall()||this._default,this._min,this._max)}}let k=class{constructor(e,t){this._logService=e,this._data=new Map,this._isDev=t.isExtensionDevelopment||!t.isBuilt}for(e,t,n){const r=n?.min??50,i=n?.max??r**2,s=n?.key??void 0,o=`${p.of(e)},${r}${s?","+s:""}`;let a=this._data.get(o);return a||(this._isDev?(this._logService.debug(`[DEBOUNCE: ${t}] is disabled in developed mode`),a=new b(1.5*r)):a=new _(this._logService,t,e,0|this._overallAverage()||1.5*r,r,i),this._data.set(o,a)),a}_overallAverage(){const e=new o;for(const t of this._data.values())e.update(t.default());return e.value}};k=g([f(0,u.rr),f(1,c)],k),(0,h.v)(m,k,1)},6942:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ILanguageFeaturesService:()=>r});const r=(0,n(3591).u1)("ILanguageFeaturesService")},2661:(e,t,n)=>{"use strict";n.r(t),n.d(t,{LanguageFeaturesService:()=>m});var r=n(1234),i=n(1484),s=n(6223),o=n(6958),a=n(8821);function l(e,t,n,r,i,s){if(Array.isArray(e)){let o=0;for(const a of e){const e=l(a,t,n,r,i,s);if(10===e)return e;e>o&&(o=e)}return o}if("string"===typeof e)return r?"*"===e?5:e===n?10:0:0;if(e){const{language:l,pattern:c,scheme:h,hasAccessToAllModels:u,notebookType:d}=e;if(!r&&!u)return 0;d&&i&&(t=i);let g=0;if(h)if(h===t.scheme)g=10;else{if("*"!==h)return 0;g=5}if(l)if(l===n)g=10;else{if("*"!==l)return 0;g=Math.max(g,5)}if(d)if(d===s)g=10;else{if("*"!==d||void 0===s)return 0;g=Math.max(g,5)}if(c){let e;if(e="string"===typeof c?c:{...c,base:(0,a.S8)(c.base)},e!==t.fsPath&&!(0,o.YW)(e,t.fsPath))return 0;g=10}return g}return 0}function c(e){return"string"!==typeof e&&(Array.isArray(e)?e.every(c):!!e.exclusive)}class h{constructor(e,t,n,r,i){this.uri=e,this.languageId=t,this.notebookUri=n,this.notebookType=r,this.recursive=i}equals(e){return this.notebookType===e.notebookType&&this.languageId===e.languageId&&this.uri.toString()===e.uri.toString()&&this.notebookUri?.toString()===e.notebookUri?.toString()&&this.recursive===e.recursive}}class u{constructor(e){this._notebookInfoResolver=e,this._clock=0,this._entries=[],this._onDidChange=new r.vl,this.onDidChange=this._onDidChange.event}register(e,t){let n={selector:e,provider:t,_score:-1,_time:this._clock++};return this._entries.push(n),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),(0,i.s)((()=>{if(n){const e=this._entries.indexOf(n);e>=0&&(this._entries.splice(e,1),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),n=void 0)}}))}has(e){return this.all(e).length>0}all(e){if(!e)return[];this._updateScores(e,!1);const t=[];for(const n of this._entries)n._score>0&&t.push(n.provider);return t}ordered(e,t=!1){const n=[];return this._orderedForEach(e,t,(e=>n.push(e.provider))),n}orderedGroups(e){const t=[];let n,r;return this._orderedForEach(e,!1,(e=>{n&&r===e._score?n.push(e.provider):(r=e._score,n=[e.provider],t.push(n))})),t}_orderedForEach(e,t,n){this._updateScores(e,t);for(const r of this._entries)r._score>0&&n(r)}_updateScores(e,t){const n=this._notebookInfoResolver?.(e.uri),r=n?new h(e.uri,e.getLanguageId(),n.uri,n.type,t):new h(e.uri,e.getLanguageId(),void 0,void 0,t);if(!this._lastCandidate?.equals(r)){this._lastCandidate=r;for(const n of this._entries)if(n._score=l(n.selector,r.uri,r.languageId,(0,s.vd)(e),r.notebookUri,r.notebookType),c(n.selector)&&n._score>0){if(!t){for(const e of this._entries)e._score=0;n._score=1e3;break}n._score=0}this._entries.sort(u._compareByScoreAndTime)}}static _compareByScoreAndTime(e,t){return e._scoret._score?-1:d(e.selector)&&!d(t.selector)?1:!d(e.selector)&&d(t.selector)?-1:e._timet._time?-1:0}}function d(e){return"string"!==typeof e&&(Array.isArray(e)?e.some(d):Boolean(e.isBuiltin))}var g=n(6942),f=n(4621);class m{constructor(){this.referenceProvider=new u(this._score.bind(this)),this.renameProvider=new u(this._score.bind(this)),this.newSymbolNamesProvider=new u(this._score.bind(this)),this.codeActionProvider=new u(this._score.bind(this)),this.definitionProvider=new u(this._score.bind(this)),this.typeDefinitionProvider=new u(this._score.bind(this)),this.declarationProvider=new u(this._score.bind(this)),this.implementationProvider=new u(this._score.bind(this)),this.documentSymbolProvider=new u(this._score.bind(this)),this.inlayHintsProvider=new u(this._score.bind(this)),this.colorProvider=new u(this._score.bind(this)),this.codeLensProvider=new u(this._score.bind(this)),this.documentFormattingEditProvider=new u(this._score.bind(this)),this.documentRangeFormattingEditProvider=new u(this._score.bind(this)),this.onTypeFormattingEditProvider=new u(this._score.bind(this)),this.signatureHelpProvider=new u(this._score.bind(this)),this.hoverProvider=new u(this._score.bind(this)),this.documentHighlightProvider=new u(this._score.bind(this)),this.multiDocumentHighlightProvider=new u(this._score.bind(this)),this.selectionRangeProvider=new u(this._score.bind(this)),this.foldingRangeProvider=new u(this._score.bind(this)),this.linkProvider=new u(this._score.bind(this)),this.inlineCompletionsProvider=new u(this._score.bind(this)),this.inlineEditProvider=new u(this._score.bind(this)),this.completionProvider=new u(this._score.bind(this)),this.linkedEditingRangeProvider=new u(this._score.bind(this)),this.documentRangeSemanticTokensProvider=new u(this._score.bind(this)),this.documentSemanticTokensProvider=new u(this._score.bind(this)),this.documentDropEditProvider=new u(this._score.bind(this)),this.documentPasteEditProvider=new u(this._score.bind(this))}_score(e){return this._notebookTypeResolver?.(e)}}(0,f.v)(g.ILanguageFeaturesService,m,1)},7596:(e,t,n)=>{"use strict";n.r(t),n.d(t,{LanguageService:()=>O});var r=n(1234),i=n(1484),s=n(9259),o=n(9861),a=n(2083),l=n(3941);const c=(e,t)=>e===t;new WeakMap;class h{constructor(e,t,n){this.owner=e,this.debugNameSource=t,this.referenceFn=n}getDebugName(e){return function(e,t){const n=d.get(e);if(n)return n;const r=function(e,t){const n=d.get(e);if(n)return n;const r=t.owner?function(e){const t=f.get(e);if(t)return t;const n=function(e){const t=e.constructor;if(t)return t.name;return"Object"}(e);let r=g.get(n)??0;r++,g.set(n,r);const i=1===r?n:`${n}#${r}`;return f.set(e,i),i}(t.owner)+".":"";let i;const s=t.debugNameSource;if(void 0!==s){if("function"!==typeof s)return r+s;if(i=s(),void 0!==i)return r+i}const o=t.referenceFn;if(void 0!==o&&(i=m(o),void 0!==i))return r+i;if(void 0!==t.owner){const n=function(e,t){for(const n in e)if(e[n]===t)return n;return}(t.owner,e);if(void 0!==n)return r+n}return}(e,t);if(r){let t=u.get(r)??0;t++,u.set(r,t);const n=1===t?r:`${r}#${t}`;return d.set(e,n),n}return}(e,this)}}const u=new Map,d=new WeakMap;const g=new Map,f=new WeakMap;function m(e){const t=e.toString(),n=/\/\*\*\s*@description\s*([^*]*)\*\//.exec(t),r=n?n[1]:void 0;return r?.trim()}let p,b,_,k;function v(){return p}class C{get TChange(){return null}reportChanges(){this.get()}read(e){return e?e.readObservable(this):this.get()}map(e,t){const n=void 0===t?void 0:e,r=void 0===t?e:t;return k({owner:n,debugName:()=>{const e=m(r);if(void 0!==e)return e;const t=/^\s*\(?\s*([a-zA-Z_$][a-zA-Z_$0-9]*)\s*\)?\s*=>\s*\1(?:\??)\.([a-zA-Z_$][a-zA-Z_$0-9]*)\s*$/.exec(r.toString());return t?`${this.debugName}.${t[2]}`:n?void 0:`${this.debugName} (mapped)`},debugReferenceFn:r},(e=>r(this.read(e),e)))}flatten(){return k({owner:void 0,debugName:()=>`${this.debugName} (flattened)`},(e=>this.read(e).read(e)))}recomputeInitiallyAndOnChange(e,t){return e.add(b(this,t)),this}keepObserved(e){return e.add(_(this)),this}}class y extends C{constructor(){super(...arguments),this.observers=new Set}addObserver(e){const t=this.observers.size;this.observers.add(e),0===t&&this.onFirstObserverAdded()}removeObserver(e){this.observers.delete(e)&&0===this.observers.size&&this.onLastObserverRemoved()}onFirstObserverAdded(){}onLastObserverRemoved(){}}function L(e,t){const n=new w(e,t);try{e(n)}finally{n.finish()}}class w{constructor(e,t){this._fn=e,this._getDebugName=t,this.updatingObservers=[],v()?.handleBeginTransaction(this)}getDebugName(){return this._getDebugName?this._getDebugName():m(this._fn)}updateObserver(e,t){this.updatingObservers.push({observer:e,observable:t}),e.beginUpdate(t)}finish(){const e=this.updatingObservers;for(let t=0;t`}beginUpdate(e){this.updateCount++;const t=1===this.updateCount;if(3===this.state&&(this.state=1,!t))for(const n of this.observers)n.handlePossibleChange(this);if(t)for(const n of this.observers)n.beginUpdate(this)}endUpdate(e){if(this.updateCount--,0===this.updateCount){const e=[...this.observers];for(const t of e)t.endUpdate(this)}(0,S.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){if(3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){this.state=1;for(const e of this.observers)e.handlePossibleChange(this)}}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){const n=!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary),r=3===this.state;if(n&&(1===this.state||r)&&(this.state=2,r))for(const e of this.observers)e.handlePossibleChange(this)}}readObservable(e){e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}addObserver(e){const t=!this.observers.has(e)&&this.updateCount>0;super.addObserver(e),t&&e.beginUpdate(this)}removeObserver(e){const t=this.observers.has(e)&&this.updateCount>0;super.removeObserver(e),t&&e.endUpdate(this)}}function E(e){return new N(new h(void 0,void 0,e),e,void 0,void 0)}class N{get debugName(){return this._debugNameData.getDebugName(this)??"(anonymous)"}constructor(e,t,n,r){this._debugNameData=e,this._runFn=t,this.createChangeSummary=n,this._handleChange=r,this.state=2,this.updateCount=0,this.disposed=!1,this.dependencies=new Set,this.dependenciesToBeRemoved=new Set,this.changeSummary=this.createChangeSummary?.(),v()?.handleAutorunCreated(this),this._runIfNeeded(),(0,i.Ay)(this)}dispose(){this.disposed=!0;for(const e of this.dependencies)e.removeObserver(this);this.dependencies.clear(),(0,i.VD)(this)}_runIfNeeded(){if(3===this.state)return;const e=this.dependenciesToBeRemoved;this.dependenciesToBeRemoved=this.dependencies,this.dependencies=e,this.state=3;const t=this.disposed;try{if(!t){v()?.handleAutorunTriggered(this);const e=this.changeSummary;this.changeSummary=this.createChangeSummary?.(),this._runFn(this,e)}}finally{t||v()?.handleAutorunFinished(this);for(const e of this.dependenciesToBeRemoved)e.removeObserver(this);this.dependenciesToBeRemoved.clear()}}toString(){return`Autorun<${this.debugName}>`}beginUpdate(){3===this.state&&(this.state=1),this.updateCount++}endUpdate(){if(1===this.updateCount)do{if(1===this.state){this.state=3;for(const e of this.dependencies)if(e.reportChanges(),2===this.state)break}this._runIfNeeded()}while(3!==this.state);this.updateCount--,(0,S.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)&&(this.state=1)}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){(!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary))&&(this.state=2)}}readObservable(e){if(this.disposed)return e.get();e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}}!function(e){e.Observer=N}(E||(E={}));function T(...e){let t,n,r;return 3===e.length?[t,n,r]=e:[n,r]=e,new A(new h(t,void 0,r),n,r,(()=>A.globalTransaction),c)}class A extends y{constructor(e,t,n,r,i){super(),this._debugNameData=e,this.event=t,this._getValue=n,this._getTransaction=r,this._equalityComparator=i,this.hasValue=!1,this.handleEvent=e=>{const t=this._getValue(e),n=this.value,r=!this.hasValue||!this._equalityComparator(n,t);let i=!1;r&&(this.value=t,this.hasValue&&(i=!0,function(e,t,n){e?t(e):L(t,n)}(this._getTransaction(),(e=>{v()?.handleFromEventObservableTriggered(this,{oldValue:n,newValue:t,change:void 0,didChange:r,hadValue:this.hasValue});for(const t of this.observers)e.updateObserver(t,this),t.handleChange(this,void 0)}),(()=>{const e=this.getDebugName();return"Event fired"+(e?`: ${e}`:"")}))),this.hasValue=!0),i||v()?.handleFromEventObservableTriggered(this,{oldValue:n,newValue:t,change:void 0,didChange:r,hadValue:this.hasValue})}}getDebugName(){return this._debugNameData.getDebugName(this)}get debugName(){const e=this.getDebugName();return"From Event"+(e?`: ${e}`:"")}onFirstObserverAdded(){this.subscription=this.event(this.handleEvent)}onLastObserverRemoved(){this.subscription.dispose(),this.subscription=void 0,this.hasValue=!1,this.value=void 0}get(){if(this.subscription)return this.hasValue||this.handleEvent(void 0),this.value;return this._getValue(void 0)}}!function(e){e.Observer=A,e.batchEventsGlobally=function(e,t){let n=!1;void 0===A.globalTransaction&&(A.globalTransaction=e,n=!0);try{t()}finally{n&&(A.globalTransaction=void 0)}}}(T||(T={}));!function(e){_=e}((function(e){const t=new I(!1,void 0);return e.addObserver(t),(0,i.s)((()=>{e.removeObserver(t)}))})),function(e){b=e}((function(e,t){const n=new I(!0,t);return e.addObserver(n),t?t(e.get()):e.reportChanges(),(0,i.s)((()=>{e.removeObserver(n)}))}));class I{constructor(e,t){this._forceRecompute=e,this._handleValue=t,this._counter=0}beginUpdate(e){this._counter++}endUpdate(e){this._counter--,0===this._counter&&this._forceRecompute&&(this._handleValue?this._handleValue(e.get()):e.reportChanges())}handlePossibleChange(e){}handleChange(e,t){}}n(4383);class O extends i.jG{static{this.instanceCount=0}constructor(e=!1){super(),this._onDidRequestBasicLanguageFeatures=this._register(new r.vl),this.onDidRequestBasicLanguageFeatures=this._onDidRequestBasicLanguageFeatures.event,this._onDidRequestRichLanguageFeatures=this._register(new r.vl),this.onDidRequestRichLanguageFeatures=this._onDidRequestRichLanguageFeatures.event,this._onDidChange=this._register(new r.vl({leakWarningThreshold:200})),this.onDidChange=this._onDidChange.event,this._requestedBasicLanguages=new Set,this._requestedRichLanguages=new Set,O.instanceCount++,this._registry=this._register(new s.LanguagesRegistry(!0,e)),this.languageIdCodec=this._registry.languageIdCodec,this._register(this._registry.onDidChange((()=>this._onDidChange.fire())))}dispose(){O.instanceCount--,super.dispose()}isRegisteredLanguageId(e){return this._registry.isRegisteredLanguageId(e)}getLanguageIdByLanguageName(e){return this._registry.getLanguageIdByLanguageName(e)}getLanguageIdByMimeType(e){return this._registry.getLanguageIdByMimeType(e)}guessLanguageIdByFilepathOrFirstLine(e,t){const n=this._registry.guessLanguageIdByFilepathOrFirstLine(e,t);return(0,o.Fy)(n,null)}createById(e){return new M(this.onDidChange,(()=>this._createAndGetLanguageIdentifier(e)))}createByFilepathOrFirstLine(e,t){return new M(this.onDidChange,(()=>{const n=this.guessLanguageIdByFilepathOrFirstLine(e,t);return this._createAndGetLanguageIdentifier(n)}))}_createAndGetLanguageIdentifier(e){return e&&this.isRegisteredLanguageId(e)||(e=l.vH),e}requestBasicLanguageFeatures(e){this._requestedBasicLanguages.has(e)||(this._requestedBasicLanguages.add(e),this._onDidRequestBasicLanguageFeatures.fire(e))}requestRichLanguageFeatures(e){this._requestedRichLanguages.has(e)||(this._requestedRichLanguages.add(e),this.requestBasicLanguageFeatures(e),a.dG.getOrCreate(e),this._onDidRequestRichLanguageFeatures.fire(e))}}class M{constructor(e,t){this._value=T(this,e,(()=>t())),this.onDidChange=r.Jh.fromObservable(this._value)}get languageId(){return this._value.get()}}},9908:(e,t,n)=>{"use strict";n.r(t),n.d(t,{clearPlatformLanguageAssociations:()=>f,getLanguageIds:()=>m,registerPlatformLanguageAssociation:()=>g});var r=n(6958),i=n(1939),s=n(6456),o=n(8821),a=n(9403),l=n(1508),c=n(3941);let h=[],u=[],d=[];function g(e,t=!1){!function(e,t,n){const i=function(e,t){return{id:e.id,mime:e.mime,filename:e.filename,extension:e.extension,filepattern:e.filepattern,firstline:e.firstline,userConfigured:t,filenameLowercase:e.filename?e.filename.toLowerCase():void 0,extensionLowercase:e.extension?e.extension.toLowerCase():void 0,filepatternLowercase:e.filepattern?(0,r.qg)(e.filepattern.toLowerCase()):void 0,filepatternOnPath:!!e.filepattern&&e.filepattern.indexOf(o.SA.sep)>=0}}(e,t);h.push(i),i.userConfigured?d.push(i):u.push(i);n&&!i.userConfigured&&h.forEach((e=>{e.mime===i.mime||e.userConfigured||(i.extension&&e.extension===i.extension&&console.warn(`Overwriting extension <<${i.extension}>> to now point to mime <<${i.mime}>>`),i.filename&&e.filename===i.filename&&console.warn(`Overwriting filename <<${i.filename}>> to now point to mime <<${i.mime}>>`),i.filepattern&&e.filepattern===i.filepattern&&console.warn(`Overwriting filepattern <<${i.filepattern}>> to now point to mime <<${i.mime}>>`),i.firstline&&e.firstline===i.firstline&&console.warn(`Overwriting firstline <<${i.firstline}>> to now point to mime <<${i.mime}>>`))}))}(e,!1,t)}function f(){h=h.filter((e=>e.userConfigured)),u=[]}function m(e,t){return function(e,t){let n;if(e)switch(e.scheme){case s.ny.file:n=e.fsPath;break;case s.ny.data:n=a.B6.parseMetaData(e).get(a.B6.META_DATA_LABEL);break;case s.ny.vscodeNotebookCell:n=void 0;break;default:n=e.path}if(!n)return[{id:"unknown",mime:i.K.unknown}];n=n.toLowerCase();const r=(0,o.P8)(n),g=p(n,r,d);if(g)return[g,{id:c.vH,mime:i.K.text}];const f=p(n,r,u);if(f)return[f,{id:c.vH,mime:i.K.text}];if(t){const e=function(e){(0,l.LU)(e)&&(e=e.substr(1));if(e.length>0)for(let t=h.length-1;t>=0;t--){const n=h[t];if(!n.firstline)continue;const r=e.match(n.firstline);if(r&&r.length>0)return n}return}(t);if(e)return[e,{id:c.vH,mime:i.K.text}]}return[{id:"unknown",mime:i.K.unknown}]}(e,t).map((e=>e.id))}function p(e,t,n){let r,i,s;for(let o=n.length-1;o>=0;o--){const a=n[o];if(t===a.filenameLowercase){r=a;break}if(a.filepattern&&(!i||a.filepattern.length>i.filepattern.length)){const n=a.filepatternOnPath?e:t;a.filepatternLowercase?.(n)&&(i=a)}a.extension&&(!s||a.extension.length>s.extension.length)&&t.endsWith(a.extensionLowercase)&&(s=a)}return r||(i||(s||void 0))}},9259:(e,t,n)=>{"use strict";n.r(t),n.d(t,{LanguageIdCodec:()=>d,LanguagesRegistry:()=>g});var r=n(1234),i=n(1484),s=n(1508),o=n(9908),a=n(3941),l=n(1646),c=n(6359);const h=Object.prototype.hasOwnProperty,u="vs.editor.nullLanguage";class d{constructor(){this._languageIdToLanguage=[],this._languageToLanguageId=new Map,this._register(u,0),this._register(a.vH,1),this._nextLanguageId=2}_register(e,t){this._languageIdToLanguage[t]=e,this._languageToLanguageId.set(e,t)}register(e){if(this._languageToLanguageId.has(e))return;const t=this._nextLanguageId++;this._register(e,t)}encodeLanguageId(e){return this._languageToLanguageId.get(e)||0}decodeLanguageId(e){return this._languageIdToLanguage[e]||u}}class g extends i.jG{static{this.instanceCount=0}constructor(e=!0,t=!1){super(),this._onDidChange=this._register(new r.vl),this.onDidChange=this._onDidChange.event,g.instanceCount++,this._warnOnOverwrite=t,this.languageIdCodec=new d,this._dynamicLanguages=[],this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},e&&(this._initializeFromRegistry(),this._register(a.W6.onDidChangeLanguages((e=>{this._initializeFromRegistry()}))))}dispose(){g.instanceCount--,super.dispose()}_initializeFromRegistry(){this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},(0,o.clearPlatformLanguageAssociations)();const e=[].concat(a.W6.getLanguages()).concat(this._dynamicLanguages);this._registerLanguages(e)}_registerLanguages(e){for(const t of e)this._registerLanguage(t);this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},Object.keys(this._languages).forEach((e=>{const t=this._languages[e];t.name&&(this._nameMap[t.name]=t.identifier),t.aliases.forEach((e=>{this._lowercaseNameMap[e.toLowerCase()]=t.identifier})),t.mimetypes.forEach((e=>{this._mimeTypesMap[e]=t.identifier}))})),c.O.as(l.Fd.Configuration).registerOverrideIdentifiers(this.getRegisteredLanguageIds()),this._onDidChange.fire()}_registerLanguage(e){const t=e.id;let n;h.call(this._languages,t)?n=this._languages[t]:(this.languageIdCodec.register(t),n={identifier:t,name:null,mimetypes:[],aliases:[],extensions:[],filenames:[],configurationFiles:[],icons:[]},this._languages[t]=n),this._mergeLanguage(n,e)}_mergeLanguage(e,t){const n=t.id;let r=null;if(Array.isArray(t.mimetypes)&&t.mimetypes.length>0&&(e.mimetypes.push(...t.mimetypes),r=t.mimetypes[0]),r||(r=`text/x-${n}`,e.mimetypes.push(r)),Array.isArray(t.extensions)){t.configuration?e.extensions=t.extensions.concat(e.extensions):e.extensions=e.extensions.concat(t.extensions);for(const e of t.extensions)(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,extension:e},this._warnOnOverwrite)}if(Array.isArray(t.filenames))for(const s of t.filenames)(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,filename:s},this._warnOnOverwrite),e.filenames.push(s);if(Array.isArray(t.filenamePatterns))for(const s of t.filenamePatterns)(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,filepattern:s},this._warnOnOverwrite);if("string"===typeof t.firstLine&&t.firstLine.length>0){let e=t.firstLine;"^"!==e.charAt(0)&&(e="^"+e);try{const t=new RegExp(e);(0,s.eY)(t)||(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,firstline:t},this._warnOnOverwrite)}catch(l){console.warn(`[${t.id}]: Invalid regular expression \`${e}\`: `,l)}}e.aliases.push(n);let i=null;if("undefined"!==typeof t.aliases&&Array.isArray(t.aliases)&&(i=0===t.aliases.length?[null]:t.aliases),null!==i)for(const s of i)s&&0!==s.length&&e.aliases.push(s);const a=null!==i&&i.length>0;if(a&&null===i[0]);else{const t=(a?i[0]:null)||n;!a&&e.name||(e.name=t)}t.configuration&&e.configurationFiles.push(t.configuration),t.icon&&e.icons.push(t.icon)}isRegisteredLanguageId(e){return!!e&&h.call(this._languages,e)}getRegisteredLanguageIds(){return Object.keys(this._languages)}getLanguageIdByLanguageName(e){const t=e.toLowerCase();return h.call(this._lowercaseNameMap,t)?this._lowercaseNameMap[t]:null}getLanguageIdByMimeType(e){return e&&h.call(this._mimeTypesMap,e)?this._mimeTypesMap[e]:null}guessLanguageIdByFilepathOrFirstLine(e,t){return e||t?(0,o.getLanguageIds)(e,t):[]}}},7550:(e,t,n)=>{"use strict";n.r(t),n.d(t,{IMarkerDecorationsService:()=>r});const r=(0,n(3591).u1)("markerDecorationsService")},448:(e,t,n)=>{"use strict";n.r(t),n.d(t,{MarkerDecorationsService:()=>L});var r,i=n(1508);!function(e){e[e.Ignore=0]="Ignore",e[e.Info=1]="Info",e[e.Warning=2]="Warning",e[e.Error=3]="Error"}(r||(r={})),function(e){const t="error",n="warning",r="info";e.fromValue=function(s){return s?i.Q_(t,s)?e.Error:i.Q_(n,s)||i.Q_("warn",s)?e.Warning:i.Q_(r,s)?e.Info:e.Ignore:e.Ignore},e.toString=function(i){switch(i){case e.Error:return t;case e.Warning:return n;case e.Info:return r;default:return"ignore"}}}(r||(r={}));const s=r;var o,a,l=n(8209),c=n(3591);!function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(o||(o={})),function(e){e.compare=function(e,t){return t-e};const t=Object.create(null);t[e.Error]=(0,l.kg)("sev.error","Error"),t[e.Warning]=(0,l.kg)("sev.warning","Warning"),t[e.Info]=(0,l.kg)("sev.info","Info"),e.toString=function(e){return t[e]||""},e.fromSeverity=function(t){switch(t){case s.Error:return e.Error;case s.Warning:return e.Warning;case s.Info:return e.Info;case s.Ignore:return e.Hint}},e.toSeverity=function(t){switch(t){case e.Error:return s.Error;case e.Warning:return s.Warning;case e.Info:return s.Info;case e.Hint:return s.Ignore}}}(o||(o={})),function(e){const t="";function n(e,n){const r=[t];return e.source?r.push(e.source.replace("\xa6","\\\xa6")):r.push(t),e.code?"string"===typeof e.code?r.push(e.code.replace("\xa6","\\\xa6")):r.push(e.code.value.replace("\xa6","\\\xa6")):r.push(t),void 0!==e.severity&&null!==e.severity?r.push(o.toString(e.severity)):r.push(t),e.message&&n?r.push(e.message.replace("\xa6","\\\xa6")):r.push(t),void 0!==e.startLineNumber&&null!==e.startLineNumber?r.push(e.startLineNumber.toString()):r.push(t),void 0!==e.startColumn&&null!==e.startColumn?r.push(e.startColumn.toString()):r.push(t),void 0!==e.endLineNumber&&null!==e.endLineNumber?r.push(e.endLineNumber.toString()):r.push(t),void 0!==e.endColumn&&null!==e.endColumn?r.push(e.endColumn.toString()):r.push(t),r.push(t),r.join("\xa6")}e.makeKey=function(e){return n(e,!0)},e.makeKeyOptionalMessage=n}(a||(a={}));const h=(0,c.u1)("markerService");var u=n(1484),d=n(6223),g=n(5724),f=n(7119),m=n(3750),p=n(6677),b=n(6456),_=n(1234),k=n(5845),v=n(4320);var C=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},y=function(e,t){return function(n,r){t(n,r,e)}};let L=class extends u.jG{constructor(e,t){super(),this._markerService=t,this._onDidChangeMarker=this._register(new _.vl),this._markerDecorations=new v.fT,e.getModels().forEach((e=>this._onModelAdded(e))),this._register(e.onModelAdded(this._onModelAdded,this)),this._register(e.onModelRemoved(this._onModelRemoved,this)),this._register(this._markerService.onMarkerChanged(this._handleMarkerChange,this))}dispose(){super.dispose(),this._markerDecorations.forEach((e=>e.dispose())),this._markerDecorations.clear()}getMarker(e,t){const n=this._markerDecorations.get(e);return n&&n.getMarker(t)||null}_handleMarkerChange(e){e.forEach((e=>{const t=this._markerDecorations.get(e);t&&this._updateDecorations(t)}))}_onModelAdded(e){const t=new w(e);this._markerDecorations.set(e.uri,t),this._updateDecorations(t)}_onModelRemoved(e){const t=this._markerDecorations.get(e.uri);t&&(t.dispose(),this._markerDecorations.delete(e.uri)),e.uri.scheme!==b.ny.inMemory&&e.uri.scheme!==b.ny.internal&&e.uri.scheme!==b.ny.vscode||this._markerService?.read({resource:e.uri}).map((e=>e.owner)).forEach((t=>this._markerService.remove(t,[e.uri])))}_updateDecorations(e){const t=this._markerService.read({resource:e.model.uri,take:500});e.update(t)&&this._onDidChangeMarker.fire(e.model)}};L=C([y(0,m.IModelService),y(1,h)],L);class w extends u.jG{constructor(e){super(),this.model=e,this._map=new v.cO,this._register((0,u.s)((()=>{this.model.deltaDecorations([...this._map.values()],[]),this._map.clear()})))}update(e){const{added:t,removed:n}=function(e,t){const n=[],r=[];for(const i of e)t.has(i)||n.push(i);for(const i of t)e.has(i)||r.push(i);return{removed:n,added:r}}(new Set(this._map.keys()),new Set(e));if(0===t.length&&0===n.length)return!1;const r=n.map((e=>this._map.get(e))),i=t.map((e=>({range:this._createDecorationRange(this.model,e),options:this._createDecorationOption(e)}))),s=this.model.deltaDecorations(r,i);for(const o of n)this._map.delete(o);for(let o=0;o=t)return n;const r=e.getWordAtPosition(n.getStartPosition());r&&(n=new p.Q(n.startLineNumber,r.startColumn,n.endLineNumber,r.endColumn))}else if(t.endColumn===Number.MAX_VALUE&&1===t.startColumn&&n.startLineNumber===n.endLineNumber){const r=e.getLineFirstNonWhitespaceColumn(t.startLineNumber);r=0}}},3750:(e,t,n)=>{"use strict";n.r(t),n.d(t,{IModelService:()=>r});const r=(0,n(3591).u1)("modelService")},1773:(e,t,n)=>{"use strict";n.r(t),n.d(t,{DefaultModelSHA1Computer:()=>yi,ModelService:()=>Ci});var r=n(1234),i=n(1484),s=n(8067),o=n(9861),a=n(7661),l=n(4383),c=n(1508),h=n(9400),u=n(4454);class d{static _nextVisibleColumn(e,t,n){return 9===e?d.nextRenderTabStop(t,n):c.ne(e)||c.Ss(e)?t+2:t+1}static visibleColumnFromColumn(e,t,n){const r=Math.min(t-1,e.length),i=e.substring(0,r),s=new c.km(i);let o=0;for(;!s.eol();){const e=c.Z5(i,r,s.offset);s.nextGraphemeLength(),o=this._nextVisibleColumn(e,o,n)}return o}static columnFromVisibleColumn(e,t,n){if(t<=0)return 1;const r=e.length,i=new c.km(e);let s=0,o=1;for(;!i.eol();){const a=c.Z5(e,r,i.offset);i.nextGraphemeLength();const l=this._nextVisibleColumn(a,s,n),h=i.offset+1;if(l>=t){return l-t \n\t"}constructor(e){if(e.autoClosingPairs?this._autoClosingPairs=e.autoClosingPairs.map((e=>new C(e))):e.brackets?this._autoClosingPairs=e.brackets.map((e=>new C({open:e[0],close:e[1]}))):this._autoClosingPairs=[],e.__electricCharacterSupport&&e.__electricCharacterSupport.docComment){const t=e.__electricCharacterSupport.docComment;this._autoClosingPairs.push(new C({open:t.open,close:t.close||""}))}this._autoCloseBeforeForQuotes="string"===typeof e.autoCloseBefore?e.autoCloseBefore:w.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_QUOTES,this._autoCloseBeforeForBrackets="string"===typeof e.autoCloseBefore?e.autoCloseBefore:w.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_BRACKETS,this._surroundingPairs=e.surroundingPairs||this._autoClosingPairs}getAutoClosingPairs(){return this._autoClosingPairs}getAutoCloseBeforeSet(e){return e?this._autoCloseBeforeForQuotes:this._autoCloseBeforeForBrackets}getSurroundingPairs(){return this._surroundingPairs}}function S(e){return 0!==(3&e)}var x=n(1674);let E,N,T;function A(){return E||(E=new TextDecoder("UTF-16LE")),E}function I(){return T||(T=s.cm()?A():(N||(N=new TextDecoder("UTF-16BE")),N)),T}function O(e,t,n){const r=new Uint16Array(e.buffer,t,n);return n>0&&(65279===r[0]||65534===r[0])?function(e,t,n){const r=[];let i=0;for(let s=0;s[e[0].toLowerCase(),e[1].toLowerCase()]));const n=[];for(let o=0;o{const[n,r]=e,[i,s]=t;return n===i||n===s||r===i||r===s},i=(e,r)=>{const i=Math.min(e,r),s=Math.max(e,r);for(let o=0;o0&&s.push({open:r,close:i})}return s}(t);this.brackets=n.map(((t,r)=>new M(e,r,t.open,t.close,function(e,t,n,r){let i=[];i=i.concat(e),i=i.concat(t);for(let s=0,o=i.length;s=0&&r.push(t);for(const t of s.close)t.indexOf(e)>=0&&r.push(t)}}function B(e,t){return e.length-t.length}function F(e){if(e.length<=1)return e;const t=[],n=new Set;for(const r of e)n.has(r)||(t.push(r),n.add(r));return t}function P(e){const t=/^[\w ]+$/.test(e);return e=c.bm(e),t?`\\b${e}\\b`:e}function V(e,t){const n=`(${e.map(P).join(")|(")})`;return c.OS(n,!0,t)}const z=function(){let e=null,t=null;return function(n){return e!==n&&(e=n,t=function(e){const t=new Uint16Array(e.length);let n=0;for(let r=e.length-1;r>=0;r--)t[n++]=e.charCodeAt(r);return I().decode(t)}(e)),t}}();class j{static _findPrevBracketInText(e,t,n,r){const i=n.match(e);if(!i)return null;const s=n.length-(i.index||0),o=i[0].length,a=r+s;return new m.Q(t,a-o+1,t,a+1)}static findPrevBracketInRange(e,t,n,r,i){const s=z(n).substring(n.length-i,n.length-r);return this._findPrevBracketInText(e,t,s,r)}static findNextBracketInText(e,t,n,r){const i=n.match(e);if(!i)return null;const s=i.index||0,o=i[0].length;if(0===o)return null;const a=r+s;return new m.Q(t,a+1,t,a+1+o)}static findNextBracketInRange(e,t,n,r,i){const s=n.substring(r,i);return this.findNextBracketInText(e,t,s,r)}}class q{constructor(e){this._richEditBrackets=e}getElectricCharacters(){const e=[];if(this._richEditBrackets)for(const t of this._richEditBrackets.brackets)for(const n of t.close){const t=n.charAt(n.length-1);e.push(t)}return(0,o.dM)(e)}onElectricCharacter(e,t,n){if(!this._richEditBrackets||0===this._richEditBrackets.brackets.length)return null;const r=t.findTokenIndexAtOffset(n-1);if(S(t.getStandardTokenType(r)))return null;const i=this._richEditBrackets.reversedRegex,s=t.getLineContent().substring(0,n-1)+e,o=j.findPrevBracketInRange(i,1,s,0,s.length);if(!o)return null;const a=s.substring(o.startColumn-1,o.endColumn-1).toLowerCase();if(this._richEditBrackets.textIsOpenBracket[a])return null;const l=t.getActualLineContentBefore(o.startColumn-1);return/^\s*$/.test(l)?{matchOpenBracket:a}:null}}function W(e){return e.global&&(e.lastIndex=0),!0}class U{constructor(e){this._indentationRules=e}shouldIncrease(e){return!!(this._indentationRules&&this._indentationRules.increaseIndentPattern&&W(this._indentationRules.increaseIndentPattern)&&this._indentationRules.increaseIndentPattern.test(e))}shouldDecrease(e){return!!(this._indentationRules&&this._indentationRules.decreaseIndentPattern&&W(this._indentationRules.decreaseIndentPattern)&&this._indentationRules.decreaseIndentPattern.test(e))}shouldIndentNextLine(e){return!!(this._indentationRules&&this._indentationRules.indentNextLinePattern&&W(this._indentationRules.indentNextLinePattern)&&this._indentationRules.indentNextLinePattern.test(e))}shouldIgnore(e){return!!(this._indentationRules&&this._indentationRules.unIndentedLinePattern&&W(this._indentationRules.unIndentedLinePattern)&&this._indentationRules.unIndentedLinePattern.test(e))}getIndentMetadata(e){let t=0;return this.shouldIncrease(e)&&(t+=1),this.shouldDecrease(e)&&(t+=2),this.shouldIndentNextLine(e)&&(t+=4),this.shouldIgnore(e)&&(t+=8),t}}class ${constructor(e){(e=e||{}).brackets=e.brackets||[["(",")"],["{","}"],["[","]"]],this._brackets=[],e.brackets.forEach((e=>{const t=$._createOpenBracketRegExp(e[0]),n=$._createCloseBracketRegExp(e[1]);t&&n&&this._brackets.push({open:e[0],openRegExp:t,close:e[1],closeRegExp:n})})),this._regExpRules=e.onEnterRules||[]}onEnter(e,t,n,r){if(e>=3)for(let i=0,s=this._regExpRules.length;i!e.reg||(e.reg.lastIndex=0,e.reg.test(e.text)))))return e.action}if(e>=2&&n.length>0&&r.length>0)for(let i=0,s=this._brackets.length;i=2&&n.length>0)for(let i=0,s=this._brackets.length;i{const t=new Set;return{info:new ee(this,e,t),closing:t}})),i=new J.VV((e=>{const t=new Set,n=new Set;return{info:new te(this,e,t,n),opening:t,openingColorized:n}}));for(const[o,a]of n){const e=r.get(o),t=i.get(a);e.closing.add(t.info),t.opening.add(e.info)}const s=t.colorizedBracketPairs?Y(t.colorizedBracketPairs):n.filter((e=>!("<"===e[0]&&">"===e[1])));for(const[o,a]of s){const e=r.get(o),t=i.get(a);e.closing.add(t.info),t.openingColorized.add(e.info),t.opening.add(e.info)}this._openingBrackets=new Map([...r.cachedValues].map((([e,t])=>[e,t.info]))),this._closingBrackets=new Map([...i.cachedValues].map((([e,t])=>[e,t.info])))}get openingBrackets(){return[...this._openingBrackets.values()]}get closingBrackets(){return[...this._closingBrackets.values()]}getOpeningBracketInfo(e){return this._openingBrackets.get(e)}getClosingBracketInfo(e){return this._closingBrackets.get(e)}getBracketInfo(e){return this.getOpeningBracketInfo(e)||this.getClosingBracketInfo(e)}getBracketRegExp(e){return V(Array.from([...this._openingBrackets.keys(),...this._closingBrackets.keys()]),e)}}function Y(e){return e.filter((([e,t])=>""!==e&&""!==t))}class Z{constructor(e,t){this.config=e,this.bracketText=t}get languageId(){return this.config.languageId}}class ee extends Z{constructor(e,t,n){super(e,t),this.openedBrackets=n,this.isOpeningBracket=!0}}class te extends Z{constructor(e,t,n,r){super(e,t),this.openingBrackets=n,this.openingColorizedBrackets=r,this.isOpeningBracket=!1}closes(e){return e.config===this.config&&this.openingBrackets.has(e)}closesColorized(e){return e.config===this.config&&this.openingColorizedBrackets.has(e)}getOpeningBrackets(){return[...this.openingBrackets]}}var ne=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},re=function(e,t){return function(n,r){t(n,r,e)}};class ie{constructor(e){this.languageId=e}affects(e){return!this.languageId||this.languageId===e}}const se=(0,H.u1)("languageConfigurationService");let oe=class extends i.jG{constructor(e,t){super(),this.configurationService=e,this.languageService=t,this._registry=this._register(new ge),this.onDidChangeEmitter=this._register(new r.vl),this.onDidChange=this.onDidChangeEmitter.event,this.configurations=new Map;const n=new Set(Object.values(ae));this._register(this.configurationService.onDidChangeConfiguration((e=>{const t=e.change.keys.some((e=>n.has(e))),r=e.change.overrides.filter((([e,t])=>t.some((e=>n.has(e))))).map((([e])=>e));if(t)this.configurations.clear(),this.onDidChangeEmitter.fire(new ie(void 0));else for(const n of r)this.languageService.isRegisteredLanguageId(n)&&(this.configurations.delete(n),this.onDidChangeEmitter.fire(new ie(n)))}))),this._register(this._registry.onDidChange((e=>{this.configurations.delete(e.languageId),this.onDidChangeEmitter.fire(new ie(e.languageId))})))}register(e,t,n){return this._registry.register(e,t,n)}getLanguageConfiguration(e){let t=this.configurations.get(e);return t||(t=function(e,t,n,r){let i=t.getLanguageConfiguration(e);if(!i){if(!r.isRegisteredLanguageId(e))return new fe(e,{});i=new fe(e,{})}const s=function(e,t){const n=t.getValue(ae.brackets,{overrideIdentifier:e}),r=t.getValue(ae.colorizedBracketPairs,{overrideIdentifier:e});return{brackets:le(n),colorizedBracketPairs:le(r)}}(i.languageId,n),o=he([i.underlyingConfig,s]);return new fe(i.languageId,o)}(e,this._registry,this.configurationService,this.languageService),this.configurations.set(e,t)),t}};oe=ne([re(0,K.pG),re(1,k.L)],oe);const ae={brackets:"editor.language.brackets",colorizedBracketPairs:"editor.language.colorizedBracketPairs"};function le(e){if(Array.isArray(e))return e.map((e=>{if(Array.isArray(e)&&2===e.length)return[e[0],e[1]]})).filter((e=>!!e))}class ce{constructor(e){this.languageId=e,this._resolved=null,this._entries=[],this._order=0,this._resolved=null}register(e,t){const n=new ue(e,t,++this._order);return this._entries.push(n),this._resolved=null,(0,i.s)((()=>{for(let e=0;ee.configuration))))}}function he(e){let t={comments:void 0,brackets:void 0,wordPattern:void 0,indentationRules:void 0,onEnterRules:void 0,autoClosingPairs:void 0,surroundingPairs:void 0,autoCloseBefore:void 0,folding:void 0,colorizedBracketPairs:void 0,__electricCharacterSupport:void 0};for(const n of e)t={comments:n.comments||t.comments,brackets:n.brackets||t.brackets,wordPattern:n.wordPattern||t.wordPattern,indentationRules:n.indentationRules||t.indentationRules,onEnterRules:n.onEnterRules||t.onEnterRules,autoClosingPairs:n.autoClosingPairs||t.autoClosingPairs,surroundingPairs:n.surroundingPairs||t.surroundingPairs,autoCloseBefore:n.autoCloseBefore||t.autoCloseBefore,folding:n.folding||t.folding,colorizedBracketPairs:n.colorizedBracketPairs||t.colorizedBracketPairs,__electricCharacterSupport:n.__electricCharacterSupport||t.__electricCharacterSupport};return t}class ue{constructor(e,t,n){this.configuration=e,this.priority=t,this.order=n}static cmp(e,t){return e.priority===t.priority?e.order-t.order:e.priority-t.priority}}class de{constructor(e){this.languageId=e}}class ge extends i.jG{constructor(){super(),this._entries=new Map,this._onDidChange=this._register(new r.vl),this.onDidChange=this._onDidChange.event,this._register(this.register(Q.vH,{brackets:[["(",")"],["[","]"],["{","}"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],colorizedBracketPairs:[],folding:{offSide:!0}},0))}register(e,t,n=0){let r=this._entries.get(e);r||(r=new ce(e),this._entries.set(e,r));const s=r.register(t,n);return this._onDidChange.fire(new de(e)),(0,i.s)((()=>{s.dispose(),this._onDidChange.fire(new de(e))}))}getLanguageConfiguration(e){const t=this._entries.get(e);return t?.getResolvedConfiguration()||null}}class fe{constructor(e,t){this.languageId=e,this.underlyingConfig=t,this._brackets=null,this._electricCharacter=null,this._onEnterSupport=this.underlyingConfig.brackets||this.underlyingConfig.indentationRules||this.underlyingConfig.onEnterRules?new $(this.underlyingConfig):null,this.comments=fe._handleComments(this.underlyingConfig),this.characterPair=new w(this.underlyingConfig),this.wordDefinition=this.underlyingConfig.wordPattern||v.Ld,this.indentationRules=this.underlyingConfig.indentationRules,this.underlyingConfig.indentationRules?this.indentRulesSupport=new U(this.underlyingConfig.indentationRules):this.indentRulesSupport=null,this.foldingRules=this.underlyingConfig.folding||{},this.bracketsNew=new X(e,this.underlyingConfig)}getWordDefinition(){return(0,v.Io)(this.wordDefinition)}get brackets(){return!this._brackets&&this.underlyingConfig.brackets&&(this._brackets=new R(this.languageId,this.underlyingConfig.brackets)),this._brackets}get electricCharacter(){return this._electricCharacter||(this._electricCharacter=new q(this.brackets)),this._electricCharacter}onEnter(e,t,n,r){return this._onEnterSupport?this._onEnterSupport.onEnter(e,t,n,r):null}getAutoClosingPairs(){return new y(this.characterPair.getAutoClosingPairs())}getAutoCloseBeforeSet(e){return this.characterPair.getAutoCloseBeforeSet(e)}getSurroundingPairs(){return this.characterPair.getSurroundingPairs()}static _handleComments(e){const t=e.comments;if(!t)return null;const n={};if(t.lineComment&&(n.lineCommentToken=t.lineComment),t.blockComment){const[e,r]=t.blockComment;n.blockCommentStartToken=e,n.blockCommentEndToken=r}return n}}(0,G.v)(se,oe,1);var me=n(6223);class pe{constructor(e,t,n,r){this.range=e,this.nestingLevel=t,this.nestingLevelOfEqualBracketType=n,this.isInvalid=r}}class be{constructor(e,t,n,r,i,s){this.range=e,this.openingBracketRange=t,this.closingBracketRange=n,this.nestingLevel=r,this.nestingLevelOfEqualBracketType=i,this.bracketPairNode=s}get openingBracketInfo(){return this.bracketPairNode.openingBracket.bracketInfo}}class _e extends be{constructor(e,t,n,r,i,s,o){super(e,t,n,r,i,s),this.minVisibleColumnIndentation=o}}var ke=n(973);function ve(e){return 0===e}const Ce=2**26;function ye(e,t){return e*Ce+t}function Le(e){const t=e,n=Math.floor(t/Ce),r=t-n*Ce;return new ke.W(n,r)}function we(e,t){let n=e+t;return t>=Ce&&(n-=e%Ce),n}function Se(e,t){return e.reduce(((e,n)=>we(e,t(n))),0)}function xe(e,t){return e===t}function Ee(e,t){const n=e,r=t;if(r-n<=0)return 0;const i=Math.floor(n/Ce),s=Math.floor(r/Ce),o=r-s*Ce;if(i===s){return ye(0,o-(n-i*Ce))}return ye(s-i,o)}function Ne(e,t){return e=t}function Ie(e){return ye(e.lineNumber-1,e.column-1)}function Oe(e,t){const n=e,r=Math.floor(n/Ce),i=n-r*Ce,s=t,o=Math.floor(s/Ce),a=s-o*Ce;return new m.Q(r+1,i+1,o+1,a+1)}class Me{static fromModelContentChanges(e){return e.map((e=>{const t=m.Q.lift(e.range);return new Me(Ie(t.getStartPosition()),Ie(t.getEndPosition()),function(e){const t=(0,c.uz)(e);return ye(t.length-1,t[t.length-1].length)}(e.text))})).reverse()}constructor(e,t,n){this.startOffset=e,this.endOffset=t,this.newLength=n}toString(){return`[${Le(this.startOffset)}...${Le(this.endOffset)}) -> ${Le(this.newLength)}`}}class Re{constructor(e){this.nextEditIdx=0,this.deltaOldToNewLineCount=0,this.deltaOldToNewColumnCount=0,this.deltaLineIdxInOld=-1,this.edits=e.map((e=>De.from(e)))}getOffsetBeforeChange(e){return this.adjustNextEdit(e),this.translateCurToOld(e)}getDistanceToNextChange(e){this.adjustNextEdit(e);const t=this.edits[this.nextEditIdx],n=t?this.translateOldToCur(t.offsetObj):null;return null===n?null:Ee(e,n)}translateOldToCur(e){return e.lineCount===this.deltaLineIdxInOld?ye(e.lineCount+this.deltaOldToNewLineCount,e.columnCount+this.deltaOldToNewColumnCount):ye(e.lineCount+this.deltaOldToNewLineCount,e.columnCount)}translateCurToOld(e){const t=Le(e);return t.lineCount-this.deltaOldToNewLineCount===this.deltaLineIdxInOld?ye(t.lineCount-this.deltaOldToNewLineCount,t.columnCount-this.deltaOldToNewColumnCount):ye(t.lineCount-this.deltaOldToNewLineCount,t.columnCount)}adjustNextEdit(e){for(;this.nextEditIdx>5;if(0===r){const e=1<e};class Ve{constructor(){this.items=new Map}getKey(e){let t=this.items.get(e);return void 0===t&&(t=this.items.size,this.items.set(e,t)),t}}class ze{get length(){return this._length}constructor(e){this._length=e}}class je extends ze{static create(e,t,n){let r=e.length;return t&&(r=we(r,t.length)),n&&(r=we(r,n.length)),new je(r,e,t,n,t?t.missingOpeningBracketIds:Fe.getEmpty())}get kind(){return 2}get listHeight(){return 0}get childrenLength(){return 3}getChild(e){switch(e){case 0:return this.openingBracket;case 1:return this.child;case 2:return this.closingBracket}throw new Error("Invalid child index")}get children(){const e=[];return e.push(this.openingBracket),this.child&&e.push(this.child),this.closingBracket&&e.push(this.closingBracket),e}constructor(e,t,n,r,i){super(e),this.openingBracket=t,this.child=n,this.closingBracket=r,this.missingOpeningBracketIds=i}canBeReused(e){return null!==this.closingBracket&&!e.intersects(this.missingOpeningBracketIds)}deepClone(){return new je(this.length,this.openingBracket.deepClone(),this.child&&this.child.deepClone(),this.closingBracket&&this.closingBracket.deepClone(),this.missingOpeningBracketIds)}computeMinIndentation(e,t){return this.child?this.child.computeMinIndentation(we(e,this.openingBracket.length),t):Number.MAX_SAFE_INTEGER}}class qe extends ze{static create23(e,t,n,r=!1){let i=e.length,s=e.missingOpeningBracketIds;if(e.listHeight!==t.listHeight)throw new Error("Invalid list heights");if(i=we(i,t.length),s=s.merge(t.missingOpeningBracketIds),n){if(e.listHeight!==n.listHeight)throw new Error("Invalid list heights");i=we(i,n.length),s=s.merge(n.missingOpeningBracketIds)}return r?new Ue(i,e.listHeight+1,e,t,n,s):new We(i,e.listHeight+1,e,t,n,s)}static getEmpty(){return new He(0,0,[],Fe.getEmpty())}get kind(){return 4}get missingOpeningBracketIds(){return this._missingOpeningBracketIds}constructor(e,t,n){super(e),this.listHeight=t,this._missingOpeningBracketIds=n,this.cachedMinIndentation=-1}throwIfImmutable(){}makeLastElementMutable(){this.throwIfImmutable();const e=this.childrenLength;if(0===e)return;const t=this.getChild(e-1),n=4===t.kind?t.toMutable():t;return t!==n&&this.setChild(e-1,n),n}makeFirstElementMutable(){this.throwIfImmutable();if(0===this.childrenLength)return;const e=this.getChild(0),t=4===e.kind?e.toMutable():e;return e!==t&&this.setChild(0,t),t}canBeReused(e){if(e.intersects(this.missingOpeningBracketIds))return!1;if(0===this.childrenLength)return!1;let t=this;for(;4===t.kind;){const e=t.childrenLength;if(0===e)throw new l.D7;t=t.getChild(e-1)}return t.canBeReused(e)}handleChildrenChanged(){this.throwIfImmutable();const e=this.childrenLength;let t=this.getChild(0).length,n=this.getChild(0).missingOpeningBracketIds;for(let r=1;rthis.textBufferLineCount-1||this.lineIdx===this.textBufferLineCount-1&&this.lineCharOffset>=this.textBufferLastLineLength)return null;null===this.line&&(this.lineTokens=this.textModel.tokenization.getLineTokens(this.lineIdx+1),this.line=this.lineTokens.getLineContent(),this.lineTokenOffset=0===this.lineCharOffset?0:this.lineTokens.findTokenIndexAtOffset(this.lineCharOffset));const e=this.lineIdx,t=this.lineCharOffset;let n=0;for(;;){const r=this.lineTokens,i=r.getCount();let s=null;if(this.lineTokenOffset1e3)break}if(n>1500)break}const r=(i=e,s=t,o=this.lineIdx,a=this.lineCharOffset,i!==o?ye(o-i,a):ye(0,a-s));var i,s,o,a;return new Ze(r,0,-1,Fe.getEmpty(),new Qe(r))}}class nt{constructor(e,t){this.text=e,this._offset=0,this.idx=0;const n=t.getRegExpStr(),r=n?new RegExp(n+"|\n","gi"):null,i=[];let s,o=0,a=0,l=0,c=0;const h=[];for(let g=0;g<60;g++)h.push(new Ze(ye(0,g),0,-1,Fe.getEmpty(),new Qe(ye(0,g))));const u=[];for(let g=0;g<60;g++)u.push(new Ze(ye(1,g),0,-1,Fe.getEmpty(),new Qe(ye(1,g))));if(r)for(r.lastIndex=0;null!==(s=r.exec(e));){const e=s.index,n=s[0];if("\n"===n)o++,a=e+1;else{if(l!==e){let t;if(c===o){const n=e-l;if(nfunction(e){let t=(0,c.bm)(e);/^[\w ]+/.test(e)&&(t=`\\b${t}`);/[\w ]+$/.test(e)&&(t=`${t}\\b`);return t}(e))).join("|")}}get regExpGlobal(){if(!this.hasRegExp){const e=this.getRegExpStr();this._regExpGlobal=e?new RegExp(e,"gi"):null,this.hasRegExp=!0}return this._regExpGlobal}getToken(e){return this.map.get(e.toLowerCase())}findClosingTokenText(e){for(const[t,n]of this.map)if(2===n.kind&&n.bracketIds.intersects(e))return t}get isEmpty(){return 0===this.map.size}}class it{constructor(e,t){this.denseKeyProvider=e,this.getLanguageConfiguration=t,this.languageIdToBracketTokens=new Map}didLanguageChange(e){return this.languageIdToBracketTokens.has(e)}getSingleLanguageBracketTokens(e){let t=this.languageIdToBracketTokens.get(e);return t||(t=rt.createFromLanguage(this.getLanguageConfiguration(e),this.denseKeyProvider),this.languageIdToBracketTokens.set(e,t)),t}}function st(e,t=!1){if(0===e.length)return null;if(1===e.length)return e[0];let n=e.length;for(;n>3;){const r=n>>1;for(let i=0;i=3?e[2]:null,t)}function ot(e,t){return Math.abs(e.listHeight-t.listHeight)}function at(e,t){return e.listHeight===t.listHeight?qe.create23(e,t,null,!1):e.listHeight>t.listHeight?function(e,t){let n=e=e.toMutable();const r=[];let i;for(;;){if(t.listHeight===n.listHeight){i=t;break}if(4!==n.kind)throw new Error("unexpected");r.push(n),n=n.makeLastElementMutable()}for(let s=r.length-1;s>=0;s--){const e=r[s];i?e.childrenLength>=3?i=qe.create23(e.unappendChild(),i,null,!1):(e.appendChildOfSameHeight(i),i=void 0):e.handleChildrenChanged()}return i?qe.create23(e,i,null,!1):e}(e,t):function(e,t){let n=e=e.toMutable();const r=[];for(;t.listHeight!==n.listHeight;){if(4!==n.kind)throw new Error("unexpected");r.push(n),n=n.makeFirstElementMutable()}let i=t;for(let s=r.length-1;s>=0;s--){const e=r[s];i?e.childrenLength>=3?i=qe.create23(i,e.unprependChild(),null,!1):(e.prependChildOfSameHeight(i),i=void 0):e.handleChildrenChanged()}return i?qe.create23(i,e,null,!1):e}(t,e)}class lt{constructor(e){this.lastOffset=0,this.nextNodes=[e],this.offsets=[0],this.idxs=[]}readLongestNodeAt(e,t){if(Ne(e,this.lastOffset))throw new Error("Invalid offset");for(this.lastOffset=e;;){const n=ht(this.nextNodes);if(!n)return;const r=ht(this.offsets);if(Ne(e,r))return;if(Ne(r,e))if(we(r,n.length)<=e)this.nextNodeAfterCurrent();else{const e=ct(n);-1!==e?(this.nextNodes.push(n.getChild(e)),this.offsets.push(r),this.idxs.push(e)):this.nextNodeAfterCurrent()}else{if(t(n))return this.nextNodeAfterCurrent(),n;{const e=ct(n);if(-1===e)return void this.nextNodeAfterCurrent();this.nextNodes.push(n.getChild(e)),this.offsets.push(r),this.idxs.push(e)}}}}nextNodeAfterCurrent(){for(;;){const e=ht(this.offsets),t=ht(this.nextNodes);if(this.nextNodes.pop(),this.offsets.pop(),0===this.idxs.length)break;const n=ht(this.nextNodes),r=ct(n,this.idxs[this.idxs.length-1]);if(-1!==r){this.nextNodes.push(n.getChild(r)),this.offsets.push(we(e,t.length)),this.idxs[this.idxs.length-1]=r;break}this.idxs.pop()}}}function ct(e,t=-1){for(;;){if(++t>=e.childrenLength)return-1;if(e.getChild(t))return t}}function ht(e){return e.length>0?e[e.length-1]:void 0}function ut(e,t,n,r){return new dt(e,t,n,r).parseDocument()}class dt{constructor(e,t,n,r){if(this.tokenizer=e,this.createImmutableLists=r,this._itemsConstructed=0,this._itemsFromCache=0,n&&r)throw new Error("Not supported");this.oldNodeReader=n?new lt(n):void 0,this.positionMapper=new Re(t)}parseDocument(){this._itemsConstructed=0,this._itemsFromCache=0;let e=this.parseList(Fe.getEmpty(),0);return e||(e=qe.getEmpty()),e}parseList(e,t){const n=[];for(;;){let r=this.tryReadChildFromCache(e);if(!r){const n=this.tokenizer.peek();if(!n||2===n.kind&&n.bracketIds.intersects(e))break;r=this.parseChild(e,t+1)}4===r.kind&&0===r.childrenLength||n.push(r)}const r=this.oldNodeReader?function(e){if(0===e.length)return null;if(1===e.length)return e[0];let t=0;function n(){if(t>=e.length)return null;const n=t,r=e[n].listHeight;for(t++;t=2?st(0===n&&t===e.length?e:e.slice(n,t),!1):e[n]}let r=n(),i=n();if(!i)return r;for(let s=n();s;s=n())ot(r,i)<=ot(i,s)?(r=at(r,i),i=s):i=at(i,s);return at(r,i)}(n):st(n,this.createImmutableLists);return r}tryReadChildFromCache(e){if(this.oldNodeReader){const t=this.positionMapper.getDistanceToNextChange(this.tokenizer.offset);if(null===t||!ve(t)){const n=this.oldNodeReader.readLongestNodeAt(this.positionMapper.getOffsetBeforeChange(this.tokenizer.offset),(n=>{if(null!==t&&!Ne(n.length,t))return!1;return n.canBeReused(e)}));if(n)return this._itemsFromCache++,this.tokenizer.skip(n.length),n}}}parseChild(e,t){this._itemsConstructed++;const n=this.tokenizer.read();switch(n.kind){case 2:return new Xe(n.bracketIds,n.length);case 0:return n.astNode;case 1:{if(t>300)return new Qe(n.length);const r=e.merge(n.bracketIds),i=this.parseList(r,t+1),s=this.tokenizer.peek();return s&&2===s.kind&&(s.bracketId===n.bracketId||s.bracketIds.intersects(n.bracketIds))?(this.tokenizer.read(),je.create(n.astNode,i,s.astNode)):je.create(n.astNode,i,null)}default:throw new Error("unexpected")}}}function gt(e,t){if(0===e.length)return t;if(0===t.length)return e;const n=new o.j3(mt(e)),r=mt(t);r.push({modified:!1,lengthBefore:void 0,lengthAfter:void 0});let i=n.dequeue();function s(e){if(void 0===e){const e=n.takeWhile((e=>!0))||[];return i&&e.unshift(i),e}const t=[];for(;i&&!ve(e);){const[r,s]=i.splitAt(e);t.push(r),e=Ee(r.lengthAfter,e),i=s??n.dequeue()}return ve(e)||t.push(new ft(!1,e,e)),t}const a=[];function l(e,t,n){if(a.length>0&&xe(a[a.length-1].endOffset,e)){const e=a[a.length-1];a[a.length-1]=new Me(e.startOffset,t,we(e.newLength,n))}else a.push({startOffset:e,endOffset:t,newLength:n})}let c=0;for(const o of r){const e=s(o.lengthBefore);if(o.modified){const t=we(c,Se(e,(e=>e.lengthBefore)));l(c,t,o.lengthAfter),c=t}else for(const t of e){const e=c;c=we(c,t.lengthBefore),t.modified&&l(e,c,t.lengthAfter)}}return a}class ft{constructor(e,t,n){this.modified=e,this.lengthBefore=t,this.lengthAfter=n}splitAt(e){const t=Ee(e,this.lengthAfter);return xe(t,0)?[this,void 0]:this.modified?[new ft(this.modified,this.lengthBefore,e),new ft(this.modified,0,t)]:[new ft(this.modified,e,e),new ft(this.modified,t,t)]}toString(){return`${this.modified?"M":"U"}:${Le(this.lengthBefore)} -> ${Le(this.lengthAfter)}`}}function mt(e){const t=[];let n=0;for(const r of e){const e=Ee(n,r.startOffset);ve(e)||t.push(new ft(!1,e,e));const i=Ee(r.startOffset,r.endOffset);t.push(new ft(!0,i,r.newLength)),n=r.endOffset}return t}class pt extends i.jG{didLanguageChange(e){return this.brackets.didLanguageChange(e)}constructor(e,t){if(super(),this.textModel=e,this.getLanguageConfiguration=t,this.didChangeEmitter=new r.vl,this.denseKeyProvider=new Ve,this.brackets=new it(this.denseKeyProvider,this.getLanguageConfiguration),this.onDidChange=this.didChangeEmitter.event,this.queuedTextEditsForInitialAstWithoutTokens=[],this.queuedTextEdits=[],e.tokenization.hasTokens)2===e.tokenization.backgroundTokenizationState?(this.initialAstWithoutTokens=void 0,this.astWithTokens=this.parseDocumentFromTextBuffer([],void 0,!1)):(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer([],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens);else{const e=this.brackets.getSingleLanguageBracketTokens(this.textModel.getLanguageId()),t=new nt(this.textModel.getValue(),e);this.initialAstWithoutTokens=ut(t,[],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens}}handleDidChangeBackgroundTokenizationState(){if(2===this.textModel.tokenization.backgroundTokenizationState){const e=void 0===this.initialAstWithoutTokens;this.initialAstWithoutTokens=void 0,e||this.didChangeEmitter.fire()}}handleDidChangeTokens({ranges:e}){const t=e.map((e=>new Me(ye(e.fromLineNumber-1,0),ye(e.toLineNumber,0),ye(e.toLineNumber-e.fromLineNumber+1,0))));this.handleEdits(t,!0),this.initialAstWithoutTokens||this.didChangeEmitter.fire()}handleContentChanged(e){const t=Me.fromModelContentChanges(e.changes);this.handleEdits(t,!1)}handleEdits(e,t){const n=gt(this.queuedTextEdits,e);this.queuedTextEdits=n,this.initialAstWithoutTokens&&!t&&(this.queuedTextEditsForInitialAstWithoutTokens=gt(this.queuedTextEditsForInitialAstWithoutTokens,e))}flushQueue(){this.queuedTextEdits.length>0&&(this.astWithTokens=this.parseDocumentFromTextBuffer(this.queuedTextEdits,this.astWithTokens,!1),this.queuedTextEdits=[]),this.queuedTextEditsForInitialAstWithoutTokens.length>0&&(this.initialAstWithoutTokens&&(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer(this.queuedTextEditsForInitialAstWithoutTokens,this.initialAstWithoutTokens,!1)),this.queuedTextEditsForInitialAstWithoutTokens=[])}parseDocumentFromTextBuffer(e,t,n){const r=t;return ut(new et(this.textModel,this.brackets),e,r,n)}getBracketsInRange(e,t){this.flushQueue();const n=ye(e.startLineNumber-1,e.startColumn-1),r=ye(e.endLineNumber-1,e.endColumn-1);return new o.c1((e=>{const i=this.initialAstWithoutTokens||this.astWithTokens;kt(i,0,i.length,n,r,e,0,0,new Map,t)}))}getBracketPairsInRange(e,t){this.flushQueue();const n=Ie(e.getStartPosition()),r=Ie(e.getEndPosition());return new o.c1((e=>{const i=this.initialAstWithoutTokens||this.astWithTokens,s=new vt(e,t,this.textModel);Ct(i,0,i.length,n,r,s,0,new Map)}))}getFirstBracketAfter(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return _t(t,0,t.length,Ie(e))}getFirstBracketBefore(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return bt(t,0,t.length,Ie(e))}}function bt(e,t,n,r){if(4===e.kind||2===e.kind){const i=[];for(const r of e.children)n=we(t,r.length),i.push({nodeOffsetStart:t,nodeOffsetEnd:n}),t=n;for(let t=i.length-1;t>=0;t--){const{nodeOffsetStart:n,nodeOffsetEnd:s}=i[t];if(Ne(n,r)){const i=bt(e.children[t],n,s,r);if(i)return i}}return null}if(3===e.kind)return null;if(1===e.kind){const r=Oe(t,n);return{bracketInfo:e.bracketInfo,range:r}}return null}function _t(e,t,n,r){if(4===e.kind||2===e.kind){for(const i of e.children){if(Ne(r,n=we(t,i.length))){const e=_t(i,t,n,r);if(e)return e}t=n}return null}if(3===e.kind)return null;if(1===e.kind){const r=Oe(t,n);return{bracketInfo:e.bracketInfo,range:r}}return null}function kt(e,t,n,r,i,s,o,a,l,c,h=!1){if(o>200)return!0;e:for(;;)switch(e.kind){case 4:{const a=e.childrenLength;for(let h=0;h200)return!0;let l=!0;if(2===e.kind){let c=0;if(a){let t=a.get(e.openingBracket.text);void 0===t&&(t=0),c=t,t++,a.set(e.openingBracket.text,t)}const h=we(t,e.openingBracket.length);let u=-1;if(s.includeMinIndentation&&(u=e.computeMinIndentation(t,s.textModel)),l=s.push(new _e(Oe(t,n),Oe(t,h),e.closingBracket?Oe(we(h,e.child?.length||0),n):void 0,o,c,e,u)),t=h,l&&e.child){const c=e.child;if(n=we(t,c.length),Te(t,i)&&Ae(n,r)&&(l=Ct(c,t,n,r,i,s,o+1,a),!l))return!1}a?.set(e.openingBracket.text,c)}else{let n=t;for(const t of e.children){const e=n;if(n=we(n,t.length),Te(e,i)&&Te(r,n)&&(l=Ct(t,e,n,r,i,s,o,a),!l))return!1}}return l}class yt extends i.jG{get canBuildAST(){return this.textModel.getValueLength()<=5e6}constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t,this.bracketPairsTree=this._register(new i.HE),this.onDidChangeEmitter=new r.vl,this.onDidChange=this.onDidChangeEmitter.event,this.bracketsRequested=!1}handleLanguageConfigurationServiceChange(e){e.languageId&&!this.bracketPairsTree.value?.object.didLanguageChange(e.languageId)||(this.bracketPairsTree.clear(),this.updateBracketPairsTree())}handleDidChangeOptions(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeLanguage(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeContent(e){this.bracketPairsTree.value?.object.handleContentChanged(e)}handleDidChangeBackgroundTokenizationState(){this.bracketPairsTree.value?.object.handleDidChangeBackgroundTokenizationState()}handleDidChangeTokens(e){this.bracketPairsTree.value?.object.handleDidChangeTokens(e)}updateBracketPairsTree(){if(this.bracketsRequested&&this.canBuildAST){if(!this.bracketPairsTree.value){const n=new i.Cm;this.bracketPairsTree.value=(e=n.add(new pt(this.textModel,(e=>this.languageConfigurationService.getLanguageConfiguration(e)))),t=n,{object:e,dispose:()=>t?.dispose()}),n.add(this.bracketPairsTree.value.object.onDidChange((e=>this.onDidChangeEmitter.fire(e)))),this.onDidChangeEmitter.fire()}}else this.bracketPairsTree.value&&(this.bracketPairsTree.clear(),this.onDidChangeEmitter.fire());var e,t}getBracketPairsInRange(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!1)||o.c1.empty}getBracketPairsInRangeWithMinIndentation(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!0)||o.c1.empty}getBracketsInRange(e,t=!1){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketsInRange(e,t)||o.c1.empty}findMatchingBracketUp(e,t,n){const r=this.textModel.validatePosition(t),i=this.textModel.getLanguageIdAtPosition(r.lineNumber,r.column);if(this.canBuildAST){const n=this.languageConfigurationService.getLanguageConfiguration(i).bracketsNew.getClosingBracketInfo(e);if(!n)return null;const r=this.getBracketPairsInRange(m.Q.fromPositions(t,t)).findLast((e=>n.closes(e.openingBracketInfo)));return r?r.openingBracketRange:null}{const t=e.toLowerCase(),s=this.languageConfigurationService.getLanguageConfiguration(i).brackets;if(!s)return null;const o=s.textIsBracket[t];return o?St(this._findMatchingBracketUp(o,r,Lt(n))):null}}matchBracket(e,t){if(this.canBuildAST){const t=this.getBracketPairsInRange(m.Q.fromPositions(e,e)).filter((t=>void 0!==t.closingBracketRange&&(t.openingBracketRange.containsPosition(e)||t.closingBracketRange.containsPosition(e)))).findLastMaxBy((0,o.VE)((t=>t.openingBracketRange.containsPosition(e)?t.openingBracketRange:t.closingBracketRange),m.Q.compareRangesUsingStarts));return t?[t.openingBracketRange,t.closingBracketRange]:null}{const n=Lt(t);return this._matchBracket(this.textModel.validatePosition(e),n)}}_establishBracketSearchOffsets(e,t,n,r){const i=t.getCount(),s=t.getLanguageId(r);let o=Math.max(0,e.column-1-n.maxBracketLength);for(let l=r-1;l>=0;l--){const e=t.getEndOffset(l);if(e<=o)break;if(S(t.getStandardTokenType(l))||t.getLanguageId(l)!==s){o=e;break}}let a=Math.min(t.getLineContent().length,e.column-1+n.maxBracketLength);for(let l=r+1;l=a)break;if(S(t.getStandardTokenType(l))||t.getLanguageId(l)!==s){a=e;break}}return{searchStartOffset:o,searchEndOffset:a}}_matchBracket(e,t){const n=e.lineNumber,r=this.textModel.tokenization.getLineTokens(n),i=this.textModel.getLineContent(n),s=r.findTokenIndexAtOffset(e.column-1);if(s<0)return null;const o=this.languageConfigurationService.getLanguageConfiguration(r.getLanguageId(s)).brackets;if(o&&!S(r.getStandardTokenType(s))){let{searchStartOffset:a,searchEndOffset:l}=this._establishBracketSearchOffsets(e,r,o,s),c=null;for(;;){const r=j.findNextBracketInRange(o.forwardRegex,n,i,a,l);if(!r)break;if(r.startColumn<=e.column&&e.column<=r.endColumn){const e=i.substring(r.startColumn-1,r.endColumn-1).toLowerCase(),n=this._matchFoundBracket(r,o.textIsBracket[e],o.textIsOpenBracket[e],t);if(n){if(n instanceof wt)return null;c=n}}a=r.endColumn-1}if(c)return c}if(s>0&&r.getStartOffset(s)===e.column-1){const o=s-1,a=this.languageConfigurationService.getLanguageConfiguration(r.getLanguageId(o)).brackets;if(a&&!S(r.getStandardTokenType(o))){const{searchStartOffset:s,searchEndOffset:l}=this._establishBracketSearchOffsets(e,r,a,o),c=j.findPrevBracketInRange(a.reversedRegex,n,i,s,l);if(c&&c.startColumn<=e.column&&e.column<=c.endColumn){const e=i.substring(c.startColumn-1,c.endColumn-1).toLowerCase(),n=this._matchFoundBracket(c,a.textIsBracket[e],a.textIsOpenBracket[e],t);if(n)return n instanceof wt?null:n}}}return null}_matchFoundBracket(e,t,n,r){if(!t)return null;const i=n?this._findMatchingBracketDown(t,e.getEndPosition(),r):this._findMatchingBracketUp(t,e.getStartPosition(),r);return i?i instanceof wt?i:[e,i]:null}_findMatchingBracketUp(e,t,n){const r=e.languageId,i=e.reversedRegex;let s=-1,o=0;const a=(t,r,a,l)=>{for(;;){if(n&&++o%100===0&&!n())return wt.INSTANCE;const c=j.findPrevBracketInRange(i,t,r,a,l);if(!c)break;const h=r.substring(c.startColumn-1,c.endColumn-1).toLowerCase();if(e.isOpen(h)?s++:e.isClose(h)&&s--,0===s)return c;l=c.startColumn-1}return null};for(let l=t.lineNumber;l>=1;l--){const e=this.textModel.tokenization.getLineTokens(l),n=e.getCount(),i=this.textModel.getLineContent(l);let s=n-1,o=i.length,c=i.length;l===t.lineNumber&&(s=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,c=t.column-1);let h=!0;for(;s>=0;s--){const t=e.getLanguageId(s)===r&&!S(e.getStandardTokenType(s));if(t)h?o=e.getStartOffset(s):(o=e.getStartOffset(s),c=e.getEndOffset(s));else if(h&&o!==c){const e=a(l,i,o,c);if(e)return e}h=t}if(h&&o!==c){const e=a(l,i,o,c);if(e)return e}}return null}_findMatchingBracketDown(e,t,n){const r=e.languageId,i=e.forwardRegex;let s=1,o=0;const a=(t,r,a,l)=>{for(;;){if(n&&++o%100===0&&!n())return wt.INSTANCE;const c=j.findNextBracketInRange(i,t,r,a,l);if(!c)break;const h=r.substring(c.startColumn-1,c.endColumn-1).toLowerCase();if(e.isOpen(h)?s++:e.isClose(h)&&s--,0===s)return c;a=c.endColumn-1}return null},l=this.textModel.getLineCount();for(let c=t.lineNumber;c<=l;c++){const e=this.textModel.tokenization.getLineTokens(c),n=e.getCount(),i=this.textModel.getLineContent(c);let s=0,o=0,l=0;c===t.lineNumber&&(s=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,l=t.column-1);let h=!0;for(;s=1;s--){const e=this.textModel.tokenization.getLineTokens(s),o=e.getCount(),a=this.textModel.getLineContent(s);let l=o-1,c=a.length,h=a.length;if(s===t.lineNumber){l=e.findTokenIndexAtOffset(t.column-1),c=t.column-1,h=t.column-1;const s=e.getLanguageId(l);n!==s&&(n=s,r=this.languageConfigurationService.getLanguageConfiguration(n).brackets,i=this.languageConfigurationService.getLanguageConfiguration(n).bracketsNew)}let u=!0;for(;l>=0;l--){const t=e.getLanguageId(l);if(n!==t){if(r&&i&&u&&c!==h){const e=j.findPrevBracketInRange(r.reversedRegex,s,a,c,h);if(e)return this._toFoundBracket(i,e);u=!1}n=t,r=this.languageConfigurationService.getLanguageConfiguration(n).brackets,i=this.languageConfigurationService.getLanguageConfiguration(n).bracketsNew}const o=!!r&&!S(e.getStandardTokenType(l));if(o)u?c=e.getStartOffset(l):(c=e.getStartOffset(l),h=e.getEndOffset(l));else if(i&&r&&u&&c!==h){const e=j.findPrevBracketInRange(r.reversedRegex,s,a,c,h);if(e)return this._toFoundBracket(i,e)}u=o}if(i&&r&&u&&c!==h){const e=j.findPrevBracketInRange(r.reversedRegex,s,a,c,h);if(e)return this._toFoundBracket(i,e)}}return null}findNextBracket(e){const t=this.textModel.validatePosition(e);if(this.canBuildAST)return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getFirstBracketAfter(t)||null;const n=this.textModel.getLineCount();let r=null,i=null,s=null;for(let o=t.lineNumber;o<=n;o++){const e=this.textModel.tokenization.getLineTokens(o),n=e.getCount(),a=this.textModel.getLineContent(o);let l=0,c=0,h=0;if(o===t.lineNumber){l=e.findTokenIndexAtOffset(t.column-1),c=t.column-1,h=t.column-1;const n=e.getLanguageId(l);r!==n&&(r=n,i=this.languageConfigurationService.getLanguageConfiguration(r).brackets,s=this.languageConfigurationService.getLanguageConfiguration(r).bracketsNew)}let u=!0;for(;lvoid 0!==t.closingBracketRange&&t.range.strictContainsRange(e)));return t?[t.openingBracketRange,t.closingBracketRange]:null}const r=Lt(t),i=this.textModel.getLineCount(),s=new Map;let o=[];const a=(e,t)=>{if(!s.has(e)){const n=[];for(let e=0,r=t?t.brackets.length:0;e{for(;;){if(r&&++l%100===0&&!r())return wt.INSTANCE;const a=j.findNextBracketInRange(e.forwardRegex,t,n,i,s);if(!a)break;const c=n.substring(a.startColumn-1,a.endColumn-1).toLowerCase(),h=e.textIsBracket[c];if(h&&(h.isOpen(c)?o[h.index]++:h.isClose(c)&&o[h.index]--,-1===o[h.index]))return this._matchFoundBracket(a,h,!1,r);i=a.endColumn-1}return null};let h=null,u=null;for(let d=n.lineNumber;d<=i;d++){const e=this.textModel.tokenization.getLineTokens(d),t=e.getCount(),r=this.textModel.getLineContent(d);let i=0,s=0,o=0;if(d===n.lineNumber){i=e.findTokenIndexAtOffset(n.column-1),s=n.column-1,o=n.column-1;const t=e.getLanguageId(i);h!==t&&(h=t,u=this.languageConfigurationService.getLanguageConfiguration(h).brackets,a(h,u))}let l=!0;for(;i!0;{const t=Date.now();return()=>Date.now()-t<=e}}class wt{static{this.INSTANCE=new wt}constructor(){this._searchCanceledBrand=void 0}}function St(e){return e instanceof wt?null:e}var xt=n(7119),Et=n(5724);class Nt extends i.jG{constructor(e){super(),this.textModel=e,this.colorProvider=new Tt,this.onDidChangeEmitter=new r.vl,this.onDidChange=this.onDidChangeEmitter.event,this.colorizationOptions=e.getOptions().bracketPairColorizationOptions,this._register(e.bracketPairs.onDidChange((e=>{this.onDidChangeEmitter.fire()})))}handleDidChangeOptions(e){this.colorizationOptions=this.textModel.getOptions().bracketPairColorizationOptions}getDecorationsInRange(e,t,n,r){if(r)return[];if(void 0===t)return[];if(!this.colorizationOptions.enabled)return[];return this.textModel.bracketPairs.getBracketsInRange(e,!0).map((e=>({id:`bracket${e.range.toString()}-${e.nestingLevel}`,options:{description:"BracketPairColorization",inlineClassName:this.colorProvider.getInlineClassName(e,this.colorizationOptions.independentColorPoolPerBracketType)},ownerId:0,range:e.range}))).toArray()}getAllDecorations(e,t){return void 0===e?[]:this.colorizationOptions.enabled?this.getDecorationsInRange(new m.Q(1,1,this.textModel.getLineCount(),1),e,t):[]}}class Tt{constructor(){this.unexpectedClosingBracketClassName="unexpected-closing-bracket"}getInlineClassName(e,t){return e.isInvalid?this.unexpectedClosingBracketClassName:this.getInlineClassNameOfLevel(t?e.nestingLevelOfEqualBracketType:e.nestingLevel)}getInlineClassNameOfLevel(e){return"bracket-highlighting-"+e%30}}(0,Et.zy)(((e,t)=>{const n=[xt.sN,xt.lQ,xt.ss,xt.l5,xt.sH,xt.zp],r=new Tt;t.addRule(`.monaco-editor .${r.unexpectedClosingBracketClassName} { color: ${e.getColor(xt.s7)}; }`);const i=n.map((t=>e.getColor(t))).filter((e=>!!e)).filter((e=>!e.isTransparent()));for(let s=0;s<30;s++){const e=i[s%i.length];t.addRule(`.monaco-editor .${r.getInlineClassNameOfLevel(s)} { color: ${e}; }`)}}));var At=n(8209);function It(e){return e.replace(/\n/g,"\\n").replace(/\r/g,"\\r")}class Ot{get oldLength(){return this.oldText.length}get oldEnd(){return this.oldPosition+this.oldText.length}get newLength(){return this.newText.length}get newEnd(){return this.newPosition+this.newText.length}constructor(e,t,n,r){this.oldPosition=e,this.oldText=t,this.newPosition=n,this.newText=r}toString(){return 0===this.oldText.length?`(insert@${this.oldPosition} "${It(this.newText)}")`:0===this.newText.length?`(delete@${this.oldPosition} "${It(this.oldText)}")`:`(replace@${this.oldPosition} "${It(this.oldText)}" with "${It(this.newText)}")`}static _writeStringSize(e){return 4+2*e.length}static _writeString(e,t,n){const r=t.length;x.Sw(e,r,n),n+=4;for(let i=0;i0&&(this.changes=(s=this.changes,o=t,null===s||0===s.length?o:new Mt(s,o).compress())),this.afterEOL=n,this.afterVersionId=r,this.afterCursorState=i}static _writeSelectionsSize(e){return 4+16*(e?e.length:0)}static _writeSelections(e,t,n){if(x.Sw(e,t?t.length:0,n),n+=4,t)for(const r of t)x.Sw(e,r.selectionStartLineNumber,n),n+=4,x.Sw(e,r.selectionStartColumn,n),n+=4,x.Sw(e,r.positionLineNumber,n),n+=4,x.Sw(e,r.positionColumn,n),n+=4;return n}static _readSelections(e,t,n){const r=x.bb(e,t);t+=4;for(let i=0;ie.toString())).join(", ")}matchesResource(e){return(h.r.isUri(this.model)?this.model:this.model.uri).toString()===e.toString()}setModel(e){this.model=e}canAppend(e){return this.model===e&&this._data instanceof Bt}append(e,t,n,r,i){this._data instanceof Bt&&this._data.append(e,t,n,r,i)}close(){this._data instanceof Bt&&(this._data=this._data.serialize())}open(){this._data instanceof Bt||(this._data=Bt.deserialize(this._data))}undo(){if(h.r.isUri(this.model))throw new Error("Invalid SingleModelEditStackElement");this._data instanceof Bt&&(this._data=this._data.serialize());const e=Bt.deserialize(this._data);this.model._applyUndo(e.changes,e.beforeEOL,e.beforeVersionId,e.beforeCursorState)}redo(){if(h.r.isUri(this.model))throw new Error("Invalid SingleModelEditStackElement");this._data instanceof Bt&&(this._data=this._data.serialize());const e=Bt.deserialize(this._data);this.model._applyRedo(e.changes,e.afterEOL,e.afterVersionId,e.afterCursorState)}heapSize(){return this._data instanceof Bt&&(this._data=this._data.serialize()),this._data.byteLength+168}}class Pt{get resources(){return this._editStackElementsArr.map((e=>e.resource))}constructor(e,t,n){this.label=e,this.code=t,this.type=1,this._isOpen=!0,this._editStackElementsArr=n.slice(0),this._editStackElementsMap=new Map;for(const r of this._editStackElementsArr){const e=Dt(r.resource);this._editStackElementsMap.set(e,r)}this._delegate=null}prepareUndoRedo(){if(this._delegate)return this._delegate.prepareUndoRedo(this)}matchesResource(e){const t=Dt(e);return this._editStackElementsMap.has(t)}setModel(e){const t=Dt(h.r.isUri(e)?e:e.uri);this._editStackElementsMap.has(t)&&this._editStackElementsMap.get(t).setModel(e)}canAppend(e){if(!this._isOpen)return!1;const t=Dt(e.uri);if(this._editStackElementsMap.has(t)){return this._editStackElementsMap.get(t).canAppend(e)}return!1}append(e,t,n,r,i){const s=Dt(e.uri);this._editStackElementsMap.get(s).append(e,t,n,r,i)}close(){this._isOpen=!1}open(){}undo(){this._isOpen=!1;for(const e of this._editStackElementsArr)e.undo()}redo(){for(const e of this._editStackElementsArr)e.redo()}heapSize(e){const t=Dt(e);if(this._editStackElementsMap.has(t)){return this._editStackElementsMap.get(t).heapSize()}return 0}split(){return this._editStackElementsArr}toString(){const e=[];for(const t of this._editStackElementsArr)e.push(`${(0,Rt.P8)(t.resource)}: ${t}`);return`{${e.join(", ")}}`}}function Vt(e){return"\n"===e.getEOL()?0:1}function zt(e){return!!e&&(e instanceof Ft||e instanceof Pt)}class jt{constructor(e,t){this._model=e,this._undoRedoService=t}pushStackElement(){const e=this._undoRedoService.getLastElement(this._model.uri);zt(e)&&e.close()}popStackElement(){const e=this._undoRedoService.getLastElement(this._model.uri);zt(e)&&e.open()}clear(){this._undoRedoService.removeElements(this._model.uri)}_getOrCreateEditStackElement(e,t){const n=this._undoRedoService.getLastElement(this._model.uri);if(zt(n)&&n.canAppend(this._model))return n;const r=new Ft(At.kg("edit","Typing"),"undoredo.textBufferEdit",this._model,e);return this._undoRedoService.pushElement(r,t),r}pushEOL(e){const t=this._getOrCreateEditStackElement(null,void 0);this._model.setEOL(e),t.append(this._model,[],Vt(this._model),this._model.getAlternativeVersionId(),null)}pushEditOperation(e,t,n,r){const i=this._getOrCreateEditStackElement(e,r),s=this._model.applyEdits(t,!0),o=jt._computeCursorState(n,s),a=s.map(((e,t)=>({index:t,textChange:e.textChange})));return a.sort(((e,t)=>e.textChange.oldPosition===t.textChange.oldPosition?e.index-t.index:e.textChange.oldPosition-t.textChange.oldPosition)),i.append(this._model,a.map((e=>e.textChange)),Vt(this._model),this._model.getAlternativeVersionId(),o),o}static _computeCursorState(e,t){try{return e?e(t):null}catch(n){return(0,l.dz)(n),null}}}var qt,Wt=n(6041);class Ut extends i.jG{constructor(){super(...arguments),this._isDisposed=!1}dispose(){super.dispose(),this._isDisposed=!0}assertNotDisposed(){if(this._isDisposed)throw new Error("TextModelPart is disposed!")}}!function(e){e[e.Disabled=0]="Disabled",e[e.EnabledForActive=1]="EnabledForActive",e[e.Enabled=2]="Enabled"}(qt||(qt={}));class $t{constructor(e,t,n,r,i,s){if(this.visibleColumn=e,this.column=t,this.className=n,this.horizontalLine=r,this.forWrappedLinesAfterColumn=i,this.forWrappedLinesBeforeOrAtColumn=s,-1!==e===(-1!==t))throw new Error}}class Ht{constructor(e,t){this.top=e,this.endColumn=t}}class Kt extends Ut{constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t}getLanguageConfiguration(e){return this.languageConfigurationService.getLanguageConfiguration(e)}_computeIndentLevel(e){return function(e,t){let n=0,r=0;const i=e.length;for(;rr)throw new l.D7("Illegal value for lineNumber");const i=this.getLanguageConfiguration(this.textModel.getLanguageId()).foldingRules,s=Boolean(i&&i.offSide);let o=-2,a=-1,c=-2,h=-1;const u=e=>{if(-1!==o&&(-2===o||o>e-1)){o=-1,a=-1;for(let t=e-2;t>=0;t--){const e=this._computeIndentLevel(t);if(e>=0){o=t,a=e;break}}}if(-2===c){c=-1,h=-1;for(let t=e;t=0){c=t,h=e;break}}}};let d=-2,g=-1,f=-2,m=-1;const p=e=>{if(-2===d){d=-1,g=-1;for(let t=e-2;t>=0;t--){const e=this._computeIndentLevel(t);if(e>=0){d=t,g=e;break}}}if(-1!==f&&(-2===f||f=0){f=t,m=e;break}}}};let b=0,_=!0,k=0,v=!0,C=0,y=0;for(let l=0;_||v;l++){const i=e-l,o=e+l;l>1&&(i<1||i1&&(o>r||o>n)&&(v=!1),l>5e4&&(_=!1,v=!1);let f=-1;if(_&&i>=1){const e=this._computeIndentLevel(i-1);e>=0?(c=i-1,h=e,f=Math.ceil(e/this.textModel.getOptions().indentSize)):(u(i),f=this._getIndentLevelForWhitespaceLine(s,a,h))}let L=-1;if(v&&o<=r){const e=this._computeIndentLevel(o-1);e>=0?(d=o-1,g=e,L=Math.ceil(e/this.textModel.getOptions().indentSize)):(p(o),L=this._getIndentLevelForWhitespaceLine(s,g,m))}if(0!==l){if(1===l){if(o<=r&&L>=0&&y+1===L){_=!1,b=o,k=o,C=L;continue}if(i>=1&&f>=0&&f-1===y){v=!1,b=i,k=i,C=f;continue}if(b=e,k=e,C=y,0===C)return{startLineNumber:b,endLineNumber:k,indent:C}}_&&(f>=C?b=i:_=!1),v&&(L>=C?k=o:v=!1)}else y=f}return{startLineNumber:b,endLineNumber:k,indent:C}}getLinesBracketGuides(e,t,n,r){const i=[];for(let c=e;c<=t;c++)i.push([]);const s=!0,o=this.textModel.bracketPairs.getBracketPairsInRangeWithMinIndentation(new m.Q(e,1,t,this.textModel.getLineMaxColumn(t))).toArray();let a;if(n&&o.length>0){const r=(e<=n.lineNumber&&n.lineNumber<=t?o:this.textModel.bracketPairs.getBracketPairsInRange(m.Q.fromPositions(n)).toArray()).filter((e=>m.Q.strictContainsPosition(e.range,n)));a=(0,Wt.Uk)(r,(e=>s))?.range}const l=this.textModel.getOptions().bracketPairColorizationOptions.independentColorPoolPerBracketType,h=new Gt;for(const u of o){if(!u.closingBracketRange)continue;const n=a&&u.range.equalsRange(a);if(!n&&!r.includeInactive)continue;const s=h.getInlineClassName(u.nestingLevel,u.nestingLevelOfEqualBracketType,l)+(r.highlightActive&&n?" "+h.activeClassName:""),o=u.openingBracketRange.getStartPosition(),d=u.closingBracketRange.getStartPosition(),g=r.horizontalGuides===qt.Enabled||r.horizontalGuides===qt.EnabledForActive&&n;if(u.range.startLineNumber===u.range.endLineNumber){g&&i[u.range.startLineNumber-e].push(new $t(-1,u.openingBracketRange.getEndPosition().column,s,new Ht(!1,d.column),-1,-1));continue}const f=this.getVisibleColumnFromPosition(d),m=this.getVisibleColumnFromPosition(u.openingBracketRange.getStartPosition()),p=Math.min(m,f,u.minVisibleColumnIndentation+1);let b=!1;c.HG(this.textModel.getLineContent(u.closingBracketRange.startLineNumber))=e&&m>p&&i[o.lineNumber-e].push(new $t(p,-1,s,new Ht(!1,o.column),-1,-1)),d.lineNumber<=t&&f>p&&i[d.lineNumber-e].push(new $t(p,-1,s,new Ht(!b,d.column),-1,-1)))}for(const c of i)c.sort(((e,t)=>e.visibleColumn-t.visibleColumn));return i}getVisibleColumnFromPosition(e){return d.visibleColumnFromColumn(this.textModel.getLineContent(e.lineNumber),e.column,this.textModel.getOptions().tabSize)+1}getLinesIndentGuides(e,t){this.assertNotDisposed();const n=this.textModel.getLineCount();if(e<1||e>n)throw new Error("Illegal value for startLineNumber");if(t<1||t>n)throw new Error("Illegal value for endLineNumber");const r=this.textModel.getOptions(),i=this.getLanguageConfiguration(this.textModel.getLanguageId()).foldingRules,s=Boolean(i&&i.offSide),o=new Array(t-e+1);let a=-2,l=-1,c=-2,h=-1;for(let u=e;u<=t;u++){const t=u-e,i=this._computeIndentLevel(u-1);if(i>=0)a=u-1,l=i,o[t]=Math.ceil(i/r.indentSize);else{if(-2===a){a=-1,l=-1;for(let e=u-2;e>=0;e--){const t=this._computeIndentLevel(e);if(t>=0){a=e,l=t;break}}}if(-1!==c&&(-2===c||c=0){c=e,h=t;break}}}o[t]=this._getIndentLevelForWhitespaceLine(s,l,h)}}return o}_getIndentLevelForWhitespaceLine(e,t,n){const r=this.textModel.getOptions();return-1===t||-1===n?0:t0&&a>0)return;if(l>0&&c>0)return;const h=Math.abs(a-c),u=Math.abs(o-l);if(0===h)return i.spacesDiff=u,void(u>0&&0<=l-1&&l-10?i++:m>1&&s++,Jt(o,a,l,f,h),h.looksLikeAlignment&&(!n||t!==h.spacesDiff))continue;const b=h.spacesDiff;b<=8&&c[b]++,o=l,a=f}let u=n;i!==s&&(u=i{const n=c[t];n>e&&(e=n,d=t)})),4===d&&c[4]>0&&c[2]>0&&c[2]>=c[4]/2&&(d=2)}return{insertSpaces:u,tabSize:d}}function Yt(e){return(1&e.metadata)>>>0}function Zt(e,t){e.metadata=254&e.metadata|t}function en(e){return(2&e.metadata)>>>1===1}function tn(e,t){e.metadata=253&e.metadata|(t?1:0)<<1}function nn(e){return(4&e.metadata)>>>2===1}function rn(e,t){e.metadata=251&e.metadata|(t?1:0)<<2}function sn(e){return(64&e.metadata)>>>6===1}function on(e,t){e.metadata=191&e.metadata|(t?1:0)<<6}function an(e,t){e.metadata=231&e.metadata|t<<3}function ln(e,t){e.metadata=223&e.metadata|(t?1:0)<<5}class cn{constructor(e,t,n){this.metadata=0,this.parent=this,this.left=this,this.right=this,Zt(this,1),this.start=t,this.end=n,this.delta=0,this.maxEnd=n,this.id=e,this.ownerId=0,this.options=null,rn(this,!1),on(this,!1),an(this,1),ln(this,!1),this.cachedVersionId=0,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=n,this.range=null,tn(this,!1)}reset(e,t,n,r){this.start=t,this.end=n,this.maxEnd=n,this.cachedVersionId=e,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=n,this.range=r}setOptions(e){this.options=e;const t=this.options.className;rn(this,"squiggly-error"===t||"squiggly-warning"===t||"squiggly-info"===t),on(this,null!==this.options.glyphMarginClassName),an(this,this.options.stickiness),ln(this,this.options.collapseOnReplaceEdit)}setCachedOffsets(e,t,n){this.cachedVersionId!==n&&(this.range=null),this.cachedVersionId=n,this.cachedAbsoluteStart=e,this.cachedAbsoluteEnd=t}detach(){this.parent=null,this.left=null,this.right=null}}const hn=new cn(null,0,0);hn.parent=hn,hn.left=hn,hn.right=hn,Zt(hn,0);class un{constructor(){this.root=hn,this.requestNormalizeDelta=!1}intervalSearch(e,t,n,r,i,s){return this.root===hn?[]:function(e,t,n,r,i,s,o){let a=e.root,l=0,c=0,h=0,u=0;const d=[];let g=0;for(;a!==hn;)if(en(a))tn(a.left,!1),tn(a.right,!1),a===a.parent.right&&(l-=a.parent.delta),a=a.parent;else{if(!en(a.left)){if(c=l+a.maxEnd,cn)tn(a,!0);else{if(u=l+a.end,u>=t){a.setCachedOffsets(h,u,s);let e=!0;r&&a.ownerId&&a.ownerId!==r&&(e=!1),i&&nn(a)&&(e=!1),o&&!sn(a)&&(e=!1),e&&(d[g++]=a)}tn(a,!0),a.right===hn||en(a.right)||(l+=a.delta,a=a.right)}}return tn(e.root,!1),d}(this,e,t,n,r,i,s)}search(e,t,n,r){return this.root===hn?[]:function(e,t,n,r,i){let s=e.root,o=0,a=0,l=0;const c=[];let h=0;for(;s!==hn;){if(en(s)){tn(s.left,!1),tn(s.right,!1),s===s.parent.right&&(o-=s.parent.delta),s=s.parent;continue}if(s.left!==hn&&!en(s.left)){s=s.left;continue}a=o+s.start,l=o+s.end,s.setCachedOffsets(a,l,r);let e=!0;t&&s.ownerId&&s.ownerId!==t&&(e=!1),n&&nn(s)&&(e=!1),i&&!sn(s)&&(e=!1),e&&(c[h++]=s),tn(s,!0),s.right===hn||en(s.right)||(o+=s.delta,s=s.right)}return tn(e.root,!1),c}(this,e,t,n,r)}collectNodesFromOwner(e){return function(e,t){let n=e.root;const r=[];let i=0;for(;n!==hn;)en(n)?(tn(n.left,!1),tn(n.right,!1),n=n.parent):n.left===hn||en(n.left)?(n.ownerId===t&&(r[i++]=n),tn(n,!0),n.right===hn||en(n.right)||(n=n.right)):n=n.left;return tn(e.root,!1),r}(this,e)}collectNodesPostOrder(){return function(e){let t=e.root;const n=[];let r=0;for(;t!==hn;)en(t)?(tn(t.left,!1),tn(t.right,!1),t=t.parent):t.left===hn||en(t.left)?t.right===hn||en(t.right)?(n[r++]=t,tn(t,!0)):t=t.right:t=t.left;return tn(e.root,!1),n}(this)}insert(e){fn(this,e),this._normalizeDeltaIfNecessary()}delete(e){mn(this,e),this._normalizeDeltaIfNecessary()}resolveNode(e,t){const n=e;let r=0;for(;e!==this.root;)e===e.parent.right&&(r+=e.parent.delta),e=e.parent;const i=n.start+r,s=n.end+r;n.setCachedOffsets(i,s,t)}acceptReplace(e,t,n,r){const i=function(e,t,n){let r=e.root,i=0,s=0,o=0,a=0;const l=[];let c=0;for(;r!==hn;)if(en(r))tn(r.left,!1),tn(r.right,!1),r===r.parent.right&&(i-=r.parent.delta),r=r.parent;else{if(!en(r.left)){if(s=i+r.maxEnd,sn?tn(r,!0):(a=i+r.end,a>=t&&(r.setCachedOffsets(o,a,0),l[c++]=r),tn(r,!0),r.right===hn||en(r.right)||(i+=r.delta,r=r.right))}return tn(e.root,!1),l}(this,e,e+t);for(let s=0,o=i.length;sn?(i.start+=l,i.end+=l,i.delta+=l,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),tn(i,!0)):(tn(i,!0),i.right===hn||en(i.right)||(s+=i.delta,i=i.right))}tn(e.root,!1)}(this,e,e+t,n),this._normalizeDeltaIfNecessary();for(let s=0,o=i.length;sn)&&(1!==r&&(2===r||t))}function gn(e,t,n,r,i){const s=function(e){return(24&e.metadata)>>>3}(e),o=0===s||2===s,a=1===s||2===s,l=n-t,c=r,h=Math.min(l,c),u=e.start;let d=!1;const g=e.end;let f=!1;t<=u&&g<=n&&function(e){return(32&e.metadata)>>>5===1}(e)&&(e.start=t,d=!0,e.end=t,f=!0);{const e=i?1:l>0?2:0;!d&&dn(u,o,t,e)&&(d=!0),!f&&dn(g,a,t,e)&&(f=!0)}if(h>0&&!i){const e=l>c?2:0;!d&&dn(u,o,t+h,e)&&(d=!0),!f&&dn(g,a,t+h,e)&&(f=!0)}{const r=i?1:0;!d&&dn(u,o,n,r)&&(e.start=t+c,d=!0),!f&&dn(g,a,n,r)&&(e.end=t+c,f=!0)}const m=c-l;d||(e.start=Math.max(0,u+m)),f||(e.end=Math.max(0,g+m)),e.start>e.end&&(e.end=e.start)}function fn(e,t){if(e.root===hn)return t.parent=hn,t.left=hn,t.right=hn,Zt(t,0),e.root=t,e.root;!function(e,t){let n=0,r=e.root;const i=t.start,s=t.end;for(;;){if(yn(i,s,r.start+n,r.end+n)<0){if(r.left===hn){t.start-=n,t.end-=n,t.maxEnd-=n,r.left=t;break}r=r.left}else{if(r.right===hn){t.start-=n+r.delta,t.end-=n+r.delta,t.maxEnd-=n+r.delta,r.right=t;break}n+=r.delta,r=r.right}}t.parent=r,t.left=hn,t.right=hn,Zt(t,1)}(e,t),Cn(t.parent);let n=t;for(;n!==e.root&&1===Yt(n.parent);)if(n.parent===n.parent.parent.left){const t=n.parent.parent.right;1===Yt(t)?(Zt(n.parent,0),Zt(t,0),Zt(n.parent.parent,1),n=n.parent.parent):(n===n.parent.right&&(n=n.parent,bn(e,n)),Zt(n.parent,0),Zt(n.parent.parent,1),_n(e,n.parent.parent))}else{const t=n.parent.parent.left;1===Yt(t)?(Zt(n.parent,0),Zt(t,0),Zt(n.parent.parent,1),n=n.parent.parent):(n===n.parent.left&&(n=n.parent,_n(e,n)),Zt(n.parent,0),Zt(n.parent.parent,1),bn(e,n.parent.parent))}return Zt(e.root,0),t}function mn(e,t){let n,r;if(t.left===hn?(n=t.right,r=t,n.delta+=t.delta,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),n.start+=t.delta,n.end+=t.delta):t.right===hn?(n=t.left,r=t):(r=function(e){for(;e.left!==hn;)e=e.left;return e}(t.right),n=r.right,n.start+=r.delta,n.end+=r.delta,n.delta+=r.delta,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),r.start+=t.delta,r.end+=t.delta,r.delta=t.delta,(r.delta<-1073741824||r.delta>1073741824)&&(e.requestNormalizeDelta=!0)),r===e.root)return e.root=n,Zt(n,0),t.detach(),pn(),vn(n),void(e.root.parent=hn);const i=1===Yt(r);if(r===r.parent.left?r.parent.left=n:r.parent.right=n,r===t?n.parent=r.parent:(r.parent===t?n.parent=r:n.parent=r.parent,r.left=t.left,r.right=t.right,r.parent=t.parent,Zt(r,Yt(t)),t===e.root?e.root=r:t===t.parent.left?t.parent.left=r:t.parent.right=r,r.left!==hn&&(r.left.parent=r),r.right!==hn&&(r.right.parent=r)),t.detach(),i)return Cn(n.parent),r!==t&&(Cn(r),Cn(r.parent)),void pn();let s;for(Cn(n),Cn(n.parent),r!==t&&(Cn(r),Cn(r.parent));n!==e.root&&0===Yt(n);)n===n.parent.left?(s=n.parent.right,1===Yt(s)&&(Zt(s,0),Zt(n.parent,1),bn(e,n.parent),s=n.parent.right),0===Yt(s.left)&&0===Yt(s.right)?(Zt(s,1),n=n.parent):(0===Yt(s.right)&&(Zt(s.left,0),Zt(s,1),_n(e,s),s=n.parent.right),Zt(s,Yt(n.parent)),Zt(n.parent,0),Zt(s.right,0),bn(e,n.parent),n=e.root)):(s=n.parent.left,1===Yt(s)&&(Zt(s,0),Zt(n.parent,1),_n(e,n.parent),s=n.parent.left),0===Yt(s.left)&&0===Yt(s.right)?(Zt(s,1),n=n.parent):(0===Yt(s.left)&&(Zt(s.right,0),Zt(s,1),bn(e,s),s=n.parent.left),Zt(s,Yt(n.parent)),Zt(n.parent,0),Zt(s.left,0),_n(e,n.parent),n=e.root));Zt(n,0),pn()}function pn(){hn.parent=hn,hn.delta=0,hn.start=0,hn.end=0}function bn(e,t){const n=t.right;n.delta+=t.delta,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),n.start+=t.delta,n.end+=t.delta,t.right=n.left,n.left!==hn&&(n.left.parent=t),n.parent=t.parent,t.parent===hn?e.root=n:t===t.parent.left?t.parent.left=n:t.parent.right=n,n.left=t,t.parent=n,vn(t),vn(n)}function _n(e,t){const n=t.left;t.delta-=n.delta,(t.delta<-1073741824||t.delta>1073741824)&&(e.requestNormalizeDelta=!0),t.start-=n.delta,t.end-=n.delta,t.left=n.right,n.right!==hn&&(n.right.parent=t),n.parent=t.parent,t.parent===hn?e.root=n:t===t.parent.right?t.parent.right=n:t.parent.left=n,n.right=t,t.parent=n,vn(t),vn(n)}function kn(e){let t=e.end;if(e.left!==hn){const n=e.left.maxEnd;n>t&&(t=n)}if(e.right!==hn){const n=e.right.maxEnd+e.delta;n>t&&(t=n)}return t}function vn(e){e.maxEnd=kn(e)}function Cn(e){for(;e!==hn;){const t=kn(e);if(e.maxEnd===t)return;e.maxEnd=t,e=e.parent}}function yn(e,t,n,r){return e===n?t-r:e-n}class Ln{constructor(e,t){this.piece=e,this.color=t,this.size_left=0,this.lf_left=0,this.parent=this,this.left=this,this.right=this}next(){if(this.right!==wn)return Sn(this.right);let e=this;for(;e.parent!==wn&&e.parent.left!==e;)e=e.parent;return e.parent===wn?wn:e.parent}prev(){if(this.left!==wn)return xn(this.left);let e=this;for(;e.parent!==wn&&e.parent.right!==e;)e=e.parent;return e.parent===wn?wn:e.parent}detach(){this.parent=null,this.left=null,this.right=null}}const wn=new Ln(null,0);function Sn(e){for(;e.left!==wn;)e=e.left;return e}function xn(e){for(;e.right!==wn;)e=e.right;return e}function En(e){return e===wn?0:e.size_left+e.piece.length+En(e.right)}function Nn(e){return e===wn?0:e.lf_left+e.piece.lineFeedCnt+Nn(e.right)}function Tn(){wn.parent=wn}function An(e,t){const n=t.right;n.size_left+=t.size_left+(t.piece?t.piece.length:0),n.lf_left+=t.lf_left+(t.piece?t.piece.lineFeedCnt:0),t.right=n.left,n.left!==wn&&(n.left.parent=t),n.parent=t.parent,t.parent===wn?e.root=n:t.parent.left===t?t.parent.left=n:t.parent.right=n,n.left=t,t.parent=n}function In(e,t){const n=t.left;t.left=n.right,n.right!==wn&&(n.right.parent=t),n.parent=t.parent,t.size_left-=n.size_left+(n.piece?n.piece.length:0),t.lf_left-=n.lf_left+(n.piece?n.piece.lineFeedCnt:0),t.parent===wn?e.root=n:t===t.parent.right?t.parent.right=n:t.parent.left=n,n.right=t,t.parent=n}function On(e,t){let n,r;if(t.left===wn?(r=t,n=r.right):t.right===wn?(r=t,n=r.left):(r=Sn(t.right),n=r.right),r===e.root)return e.root=n,n.color=0,t.detach(),Tn(),void(e.root.parent=wn);const i=1===r.color;if(r===r.parent.left?r.parent.left=n:r.parent.right=n,r===t?(n.parent=r.parent,Dn(e,n)):(r.parent===t?n.parent=r:n.parent=r.parent,Dn(e,n),r.left=t.left,r.right=t.right,r.parent=t.parent,r.color=t.color,t===e.root?e.root=r:t===t.parent.left?t.parent.left=r:t.parent.right=r,r.left!==wn&&(r.left.parent=r),r.right!==wn&&(r.right.parent=r),r.size_left=t.size_left,r.lf_left=t.lf_left,Dn(e,r)),t.detach(),n.parent.left===n){const t=En(n),r=Nn(n);if(t!==n.parent.size_left||r!==n.parent.lf_left){const i=t-n.parent.size_left,s=r-n.parent.lf_left;n.parent.size_left=t,n.parent.lf_left=r,Rn(e,n.parent,i,s)}}if(Dn(e,n.parent),i)return void Tn();let s;for(;n!==e.root&&0===n.color;)n===n.parent.left?(s=n.parent.right,1===s.color&&(s.color=0,n.parent.color=1,An(e,n.parent),s=n.parent.right),0===s.left.color&&0===s.right.color?(s.color=1,n=n.parent):(0===s.right.color&&(s.left.color=0,s.color=1,In(e,s),s=n.parent.right),s.color=n.parent.color,n.parent.color=0,s.right.color=0,An(e,n.parent),n=e.root)):(s=n.parent.left,1===s.color&&(s.color=0,n.parent.color=1,In(e,n.parent),s=n.parent.left),0===s.left.color&&0===s.right.color?(s.color=1,n=n.parent):(0===s.left.color&&(s.right.color=0,s.color=1,An(e,s),s=n.parent.left),s.color=n.parent.color,n.parent.color=0,s.left.color=0,In(e,n.parent),n=e.root));n.color=0,Tn()}function Mn(e,t){for(Dn(e,t);t!==e.root&&1===t.parent.color;)if(t.parent===t.parent.parent.left){const n=t.parent.parent.right;1===n.color?(t.parent.color=0,n.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.right&&An(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,In(e,t.parent.parent))}else{const n=t.parent.parent.left;1===n.color?(t.parent.color=0,n.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.left&&In(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,An(e,t.parent.parent))}e.root.color=0}function Rn(e,t,n,r){for(;t!==e.root&&t!==wn;)t.parent.left===t&&(t.parent.size_left+=n,t.parent.lf_left+=r),t=t.parent}function Dn(e,t){let n=0,r=0;if(t!==e.root){for(;t!==e.root&&t===t.parent.right;)t=t.parent;if(t!==e.root)for(n=En((t=t.parent).left)-t.size_left,r=Nn(t.left)-t.lf_left,t.size_left+=n,t.lf_left+=r;t!==e.root&&(0!==n||0!==r);)t.parent.left===t&&(t.parent.size_left+=n,t.parent.lf_left+=r),t=t.parent}}wn.parent=wn,wn.left=wn,wn.right=wn,wn.color=0;var Bn=n(7729);const Fn=65535;function Pn(e){let t;return t=e[e.length-1]<65536?new Uint16Array(e.length):new Uint32Array(e.length),t.set(e,0),t}class Vn{constructor(e,t,n,r,i){this.lineStarts=e,this.cr=t,this.lf=n,this.crlf=r,this.isBasicASCII=i}}function zn(e,t=!0){const n=[0];let r=1;for(let i=0,s=e.length;i(e!==wn&&this._pieces.push(e.piece),!0)))}read(){return 0===this._pieces.length?0===this._index?(this._index++,this._BOM):null:this._index>this._pieces.length-1?null:0===this._index?this._BOM+this._tree.getPieceContent(this._pieces[this._index++]):this._tree.getPieceContent(this._pieces[this._index++])}}class Un{constructor(e){this._limit=e,this._cache=[]}get(e){for(let t=this._cache.length-1;t>=0;t--){const n=this._cache[t];if(n.nodeStartOffset<=e&&n.nodeStartOffset+n.node.piece.length>=e)return n}return null}get2(e){for(let t=this._cache.length-1;t>=0;t--){const n=this._cache[t];if(n.nodeStartLineNumber&&n.nodeStartLineNumber=e)return n}return null}set(e){this._cache.length>=this._limit&&this._cache.shift(),this._cache.push(e)}validate(e){let t=!1;const n=this._cache;for(let r=0;r=e)&&(n[r]=null,t=!0)}if(t){const e=[];for(const t of n)null!==t&&e.push(t);this._cache=e}}}class $n{constructor(e,t,n){this.create(e,t,n)}create(e,t,n){this._buffers=[new qn("",[0])],this._lastChangeBufferPos={line:0,column:0},this.root=wn,this._lineCnt=1,this._length=0,this._EOL=t,this._EOLLength=t.length,this._EOLNormalized=n;let r=null;for(let i=0,s=e.length;i0){e[i].lineStarts||(e[i].lineStarts=zn(e[i].buffer));const t=new jn(i+1,{line:0,column:0},{line:e[i].lineStarts.length-1,column:e[i].buffer.length-e[i].lineStarts[e[i].lineStarts.length-1]},e[i].lineStarts.length-1,e[i].buffer.length);this._buffers.push(e[i]),r=this.rbInsertRight(r,t)}this._searchCache=new Un(1),this._lastVisitedLine={lineNumber:0,value:""},this.computeBufferMetadata()}normalizeEOL(e){const t=Fn,n=t-Math.floor(21845),r=2*n;let i="",s=0;const o=[];if(this.iterate(this.root,(t=>{const a=this.getNodeContent(t),l=a.length;if(s<=n||s+l0){const t=i.replace(/\r\n|\r|\n/g,e);o.push(new qn(t,zn(t)))}this.create(o,e,!0)}getEOL(){return this._EOL}setEOL(e){this._EOL=e,this._EOLLength=this._EOL.length,this.normalizeEOL(e)}createSnapshot(e){return new Wn(this,e)}getOffsetAt(e,t){let n=0,r=this.root;for(;r!==wn;)if(r.left!==wn&&r.lf_left+1>=e)r=r.left;else{if(r.lf_left+r.piece.lineFeedCnt+1>=e){n+=r.size_left;return n+(this.getAccumulatedValue(r,e-r.lf_left-2)+t-1)}e-=r.lf_left+r.piece.lineFeedCnt,n+=r.size_left+r.piece.length,r=r.right}return n}getPositionAt(e){e=Math.floor(e),e=Math.max(0,e);let t=this.root,n=0;const r=e;for(;t!==wn;)if(0!==t.size_left&&t.size_left>=e)t=t.left;else{if(t.size_left+t.piece.length>=e){const i=this.getIndexOf(t,e-t.size_left);if(n+=t.lf_left+i.index,0===i.index){const e=r-this.getOffsetAt(n+1,1);return new f.y(n+1,e+1)}return new f.y(n+1,i.remainder+1)}if(e-=t.size_left+t.piece.length,n+=t.lf_left+t.piece.lineFeedCnt,t.right===wn){const t=r-e-this.getOffsetAt(n+1,1);return new f.y(n+1,t+1)}t=t.right}return new f.y(1,1)}getValueInRange(e,t){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return"";const n=this.nodeAt2(e.startLineNumber,e.startColumn),r=this.nodeAt2(e.endLineNumber,e.endColumn),i=this.getValueInRange2(n,r);return t?t===this._EOL&&this._EOLNormalized&&t===this.getEOL()&&this._EOLNormalized?i:i.replace(/\r\n|\r|\n/g,t):i}getValueInRange2(e,t){if(e.node===t.node){const n=e.node,r=this._buffers[n.piece.bufferIndex].buffer,i=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);return r.substring(i+e.remainder,i+t.remainder)}let n=e.node;const r=this._buffers[n.piece.bufferIndex].buffer,i=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);let s=r.substring(i+e.remainder,i+n.piece.length);for(n=n.next();n!==wn;){const e=this._buffers[n.piece.bufferIndex].buffer,r=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);if(n===t.node){s+=e.substring(r,r+t.remainder);break}s+=e.substr(r,n.piece.length),n=n.next()}return s}getLinesContent(){const e=[];let t=0,n="",r=!1;return this.iterate(this.root,(i=>{if(i===wn)return!0;const s=i.piece;let o=s.length;if(0===o)return!0;const a=this._buffers[s.bufferIndex].buffer,l=this._buffers[s.bufferIndex].lineStarts,c=s.start.line,h=s.end.line;let u=l[c]+s.start.column;if(r&&(10===a.charCodeAt(u)&&(u++,o--),e[t++]=n,n="",r=!1,0===o))return!0;if(c===h)return this._EOLNormalized||13!==a.charCodeAt(u+o-1)?n+=a.substr(u,o):(r=!0,n+=a.substr(u,o-1)),!0;n+=this._EOLNormalized?a.substring(u,Math.max(u,l[c+1]-this._EOLLength)):a.substring(u,l[c+1]).replace(/(\r\n|\r|\n)$/,""),e[t++]=n;for(let r=c+1;re+g,t.reset(0)):(_=u.buffer,k=e=>e,t.reset(g));do{if(p=t.next(_),p){if(k(p.index)>=f)return c;this.positionInBuffer(e,k(p.index)-d,b);const t=this.getLineFeedCnt(e.piece.bufferIndex,i,b),s=b.line===i.line?b.column-i.column+r:b.column+1,o=s+p[0].length;if(h[c++]=(0,Bn.dr)(new m.Q(n+t,s,n+t,o),p,a),k(p.index)+p[0].length>=f)return c;if(c>=l)return c}}while(p);return c}findMatchesLineByLine(e,t,n,r){const i=[];let s=0;const o=new Bn.W5(t.wordSeparators,t.regex);let a=this.nodeAt2(e.startLineNumber,e.startColumn);if(null===a)return[];const l=this.nodeAt2(e.endLineNumber,e.endColumn);if(null===l)return[];let c=this.positionInBuffer(a.node,a.remainder);const h=this.positionInBuffer(l.node,l.remainder);if(a.node===l.node)return this.findMatchesInNode(a.node,o,e.startLineNumber,e.startColumn,c,h,t,n,r,s,i),i;let u=e.startLineNumber,d=a.node;for(;d!==l.node;){const l=this.getLineFeedCnt(d.piece.bufferIndex,c,d.piece.end);if(l>=1){const a=this._buffers[d.piece.bufferIndex].lineStarts,h=this.offsetInBuffer(d.piece.bufferIndex,d.piece.start),g=a[c.line+l],f=u===e.startLineNumber?e.startColumn:1;if(s=this.findMatchesInNode(d,o,u,f,c,this.positionInBuffer(d,g-h),t,n,r,s,i),s>=r)return i;u+=l}const h=u===e.startLineNumber?e.startColumn-1:0;if(u===e.endLineNumber){const a=this.getLineContent(u).substring(h,e.endColumn-1);return s=this._findMatchesInLine(t,o,a,e.endLineNumber,h,s,i,n,r),i}if(s=this._findMatchesInLine(t,o,this.getLineContent(u).substr(h),u,h,s,i,n,r),s>=r)return i;u++,a=this.nodeAt2(u,1),d=a.node,c=this.positionInBuffer(a.node,a.remainder)}if(u===e.endLineNumber){const a=u===e.startLineNumber?e.startColumn-1:0,l=this.getLineContent(u).substring(a,e.endColumn-1);return s=this._findMatchesInLine(t,o,l,e.endLineNumber,a,s,i,n,r),i}const g=u===e.startLineNumber?e.startColumn:1;return s=this.findMatchesInNode(l.node,o,u,g,c,h,t,n,r,s,i),i}_findMatchesInLine(e,t,n,r,i,s,o,a,l){const c=e.wordSeparators;if(!a&&e.simpleSearch){const t=e.simpleSearch,a=t.length,h=n.length;let u=-a;for(;-1!==(u=n.indexOf(t,u+a));)if((!c||(0,Bn.wC)(c,n,h,u,a))&&(o[s++]=new me.Dg(new m.Q(r,u+1+i,r,u+1+a+i),null),s>=l))return s;return s}let h;t.reset(0);do{if(h=t.next(n),h&&(o[s++]=(0,Bn.dr)(new m.Q(r,h.index+1+i,r,h.index+1+h[0].length+i),h,a),s>=l))return s}while(h);return s}insert(e,t,n=!1){if(this._EOLNormalized=this._EOLNormalized&&n,this._lastVisitedLine.lineNumber=0,this._lastVisitedLine.value="",this.root!==wn){const{node:n,remainder:r,nodeStartOffset:i}=this.nodeAt(e),s=n.piece,o=s.bufferIndex,a=this.positionInBuffer(n,r);if(0===n.piece.bufferIndex&&s.end.line===this._lastChangeBufferPos.line&&s.end.column===this._lastChangeBufferPos.column&&i+s.length===e&&t.lengthe){const e=[];let i=new jn(s.bufferIndex,a,s.end,this.getLineFeedCnt(s.bufferIndex,a,s.end),this.offsetInBuffer(o,s.end)-this.offsetInBuffer(o,a));if(this.shouldCheckCRLF()&&this.endWithCR(t)){if(10===this.nodeCharCodeAt(n,r)){const e={line:i.start.line+1,column:0};i=new jn(i.bufferIndex,e,i.end,this.getLineFeedCnt(i.bufferIndex,e,i.end),i.length-1),t+="\n"}}if(this.shouldCheckCRLF()&&this.startWithLF(t)){if(13===this.nodeCharCodeAt(n,r-1)){const i=this.positionInBuffer(n,r-1);this.deleteNodeTail(n,i),t="\r"+t,0===n.piece.length&&e.push(n)}else this.deleteNodeTail(n,a)}else this.deleteNodeTail(n,a);const l=this.createNewPieces(t);i.length>0&&this.rbInsertRight(n,i);let c=n;for(let t=0;t=0;s--)i=this.rbInsertLeft(i,r[s]);this.validateCRLFWithPrevNode(i),this.deleteNodes(n)}insertContentToNodeRight(e,t){this.adjustCarriageReturnFromNext(e,t)&&(e+="\n");const n=this.createNewPieces(e),r=this.rbInsertRight(t,n[0]);let i=r;for(let s=1;s=h))break;a=c+1}return n?(n.line=c,n.column=o-u,null):{line:c,column:o-u}}getLineFeedCnt(e,t,n){if(0===n.column)return n.line-t.line;const r=this._buffers[e].lineStarts;if(n.line===r.length-1)return n.line-t.line;const i=r[n.line+1],s=r[n.line]+n.column;if(i>s+1)return n.line-t.line;const o=s-1;return 13===this._buffers[e].buffer.charCodeAt(o)?n.line-t.line+1:n.line-t.line}offsetInBuffer(e,t){return this._buffers[e].lineStarts[t.line]+t.column}deleteNodes(e){for(let t=0;tFn){const t=[];for(;e.length>Fn;){const n=e.charCodeAt(65534);let r;13===n||n>=55296&&n<=56319?(r=e.substring(0,65534),e=e.substring(65534)):(r=e.substring(0,Fn),e=e.substring(Fn));const i=zn(r);t.push(new jn(this._buffers.length,{line:0,column:0},{line:i.length-1,column:r.length-i[i.length-1]},i.length-1,r.length)),this._buffers.push(new qn(r,i))}const n=zn(e);return t.push(new jn(this._buffers.length,{line:0,column:0},{line:n.length-1,column:e.length-n[n.length-1]},n.length-1,e.length)),this._buffers.push(new qn(e,n)),t}let t=this._buffers[0].buffer.length;const n=zn(e,!1);let r=this._lastChangeBufferPos;if(this._buffers[0].lineStarts[this._buffers[0].lineStarts.length-1]===t&&0!==t&&this.startWithLF(e)&&this.endWithCR(this._buffers[0].buffer)){this._lastChangeBufferPos={line:this._lastChangeBufferPos.line,column:this._lastChangeBufferPos.column+1},r=this._lastChangeBufferPos;for(let e=0;e=e-1)n=n.left;else{if(n.lf_left+n.piece.lineFeedCnt>e-1){const r=this.getAccumulatedValue(n,e-n.lf_left-2),o=this.getAccumulatedValue(n,e-n.lf_left-1),a=this._buffers[n.piece.bufferIndex].buffer,l=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);return i+=n.size_left,this._searchCache.set({node:n,nodeStartOffset:i,nodeStartLineNumber:s-(e-1-n.lf_left)}),a.substring(l+r,l+o-t)}if(n.lf_left+n.piece.lineFeedCnt===e-1){const t=this.getAccumulatedValue(n,e-n.lf_left-2),i=this._buffers[n.piece.bufferIndex].buffer,s=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);r=i.substring(s+t,s+n.piece.length);break}e-=n.lf_left+n.piece.lineFeedCnt,i+=n.size_left+n.piece.length,n=n.right}}for(n=n.next();n!==wn;){const e=this._buffers[n.piece.bufferIndex].buffer;if(n.piece.lineFeedCnt>0){const i=this.getAccumulatedValue(n,0),s=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);return r+=e.substring(s,s+i-t),r}{const t=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);r+=e.substr(t,n.piece.length)}n=n.next()}return r}computeBufferMetadata(){let e=this.root,t=1,n=0;for(;e!==wn;)t+=e.lf_left+e.piece.lineFeedCnt,n+=e.size_left+e.piece.length,e=e.right;this._lineCnt=t,this._length=n,this._searchCache.validate(this._length)}getIndexOf(e,t){const n=e.piece,r=this.positionInBuffer(e,t),i=r.line-n.start.line;if(this.offsetInBuffer(n.bufferIndex,n.end)-this.offsetInBuffer(n.bufferIndex,n.start)===t){const t=this.getLineFeedCnt(e.piece.bufferIndex,n.start,r);if(t!==i)return{index:t,remainder:0}}return{index:i,remainder:r.column}}getAccumulatedValue(e,t){if(t<0)return 0;const n=e.piece,r=this._buffers[n.bufferIndex].lineStarts,i=n.start.line+t+1;return i>n.end.line?r[n.end.line]+n.end.column-r[n.start.line]-n.start.column:r[i]-r[n.start.line]-n.start.column}deleteNodeTail(e,t){const n=e.piece,r=n.lineFeedCnt,i=this.offsetInBuffer(n.bufferIndex,n.end),s=t,o=this.offsetInBuffer(n.bufferIndex,s),a=this.getLineFeedCnt(n.bufferIndex,n.start,s),l=a-r,c=o-i,h=n.length+c;e.piece=new jn(n.bufferIndex,n.start,s,a,h),Rn(this,e,c,l)}deleteNodeHead(e,t){const n=e.piece,r=n.lineFeedCnt,i=this.offsetInBuffer(n.bufferIndex,n.start),s=t,o=this.getLineFeedCnt(n.bufferIndex,s,n.end),a=o-r,l=i-this.offsetInBuffer(n.bufferIndex,s),c=n.length+l;e.piece=new jn(n.bufferIndex,s,n.end,o,c),Rn(this,e,l,a)}shrinkNode(e,t,n){const r=e.piece,i=r.start,s=r.end,o=r.length,a=r.lineFeedCnt,l=t,c=this.getLineFeedCnt(r.bufferIndex,r.start,l),h=this.offsetInBuffer(r.bufferIndex,t)-this.offsetInBuffer(r.bufferIndex,i);e.piece=new jn(r.bufferIndex,r.start,l,c,h),Rn(this,e,h-o,c-a);const u=new jn(r.bufferIndex,n,s,this.getLineFeedCnt(r.bufferIndex,n,s),this.offsetInBuffer(r.bufferIndex,s)-this.offsetInBuffer(r.bufferIndex,n)),d=this.rbInsertRight(e,u);this.validateCRLFWithPrevNode(d)}appendToNode(e,t){this.adjustCarriageReturnFromNext(t,e)&&(t+="\n");const n=this.shouldCheckCRLF()&&this.startWithLF(t)&&this.endWithCR(e),r=this._buffers[0].buffer.length;this._buffers[0].buffer+=t;const i=zn(t,!1);for(let u=0;ue)t=t.left;else{if(t.size_left+t.piece.length>=e){r+=t.size_left;const n={node:t,remainder:e-t.size_left,nodeStartOffset:r};return this._searchCache.set(n),n}e-=t.size_left+t.piece.length,r+=t.size_left+t.piece.length,t=t.right}return null}nodeAt2(e,t){let n=this.root,r=0;for(;n!==wn;)if(n.left!==wn&&n.lf_left>=e-1)n=n.left;else{if(n.lf_left+n.piece.lineFeedCnt>e-1){const i=this.getAccumulatedValue(n,e-n.lf_left-2),s=this.getAccumulatedValue(n,e-n.lf_left-1);return r+=n.size_left,{node:n,remainder:Math.min(i+t-1,s),nodeStartOffset:r}}if(n.lf_left+n.piece.lineFeedCnt===e-1){const i=this.getAccumulatedValue(n,e-n.lf_left-2);if(i+t-1<=n.piece.length)return{node:n,remainder:i+t-1,nodeStartOffset:r};t-=n.piece.length-i;break}e-=n.lf_left+n.piece.lineFeedCnt,r+=n.size_left+n.piece.length,n=n.right}for(n=n.next();n!==wn;){if(n.piece.lineFeedCnt>0){const e=this.getAccumulatedValue(n,0),r=this.offsetOfNode(n);return{node:n,remainder:Math.min(t-1,e),nodeStartOffset:r}}if(n.piece.length>=t-1){return{node:n,remainder:t-1,nodeStartOffset:this.offsetOfNode(n)}}t-=n.piece.length,n=n.next()}return null}nodeCharCodeAt(e,t){if(e.piece.lineFeedCnt<1)return-1;const n=this._buffers[e.piece.bufferIndex],r=this.offsetInBuffer(e.piece.bufferIndex,e.piece.start)+t;return n.buffer.charCodeAt(r)}offsetOfNode(e){if(!e)return 0;let t=e.size_left;for(;e!==this.root;)e.parent.right===e&&(t+=e.parent.size_left+e.parent.piece.length),e=e.parent;return t}shouldCheckCRLF(){return!(this._EOLNormalized&&"\n"===this._EOL)}startWithLF(e){if("string"===typeof e)return 10===e.charCodeAt(0);if(e===wn||0===e.piece.lineFeedCnt)return!1;const t=e.piece,n=this._buffers[t.bufferIndex].lineStarts,r=t.start.line,i=n[r]+t.start.column;if(r===n.length-1)return!1;return!(n[r+1]>i+1)&&10===this._buffers[t.bufferIndex].buffer.charCodeAt(i)}endWithCR(e){return"string"===typeof e?13===e.charCodeAt(e.length-1):e!==wn&&0!==e.piece.lineFeedCnt&&13===this.nodeCharCodeAt(e,e.piece.length-1)}validateCRLFWithPrevNode(e){if(this.shouldCheckCRLF()&&this.startWithLF(e)){const t=e.prev();this.endWithCR(t)&&this.fixCRLF(t,e)}}validateCRLFWithNextNode(e){if(this.shouldCheckCRLF()&&this.endWithCR(e)){const t=e.next();this.startWithLF(t)&&this.fixCRLF(e,t)}}fixCRLF(e,t){const n=[],r=this._buffers[e.piece.bufferIndex].lineStarts;let i;i=0===e.piece.end.column?{line:e.piece.end.line-1,column:r[e.piece.end.line]-r[e.piece.end.line-1]-1}:{line:e.piece.end.line,column:e.piece.end.column-1};const s=e.piece.length-1,o=e.piece.lineFeedCnt-1;e.piece=new jn(e.piece.bufferIndex,e.piece.start,i,o,s),Rn(this,e,-1,-1),0===e.piece.length&&n.push(e);const a={line:t.piece.start.line+1,column:0},l=t.piece.length-1,c=this.getLineFeedCnt(t.piece.bufferIndex,a,t.piece.end);t.piece=new jn(t.piece.bufferIndex,a,t.piece.end,c,l),Rn(this,t,-1,-1),0===t.piece.length&&n.push(t);const h=this.createNewPieces("\r\n");this.rbInsertRight(e,h[0]);for(let u=0;ue.sortIndex-t.sortIndex))}this._mightContainRTL=r,this._mightContainUnusualLineTerminators=i,this._mightContainNonBasicASCII=s;const f=this._doApplyEdits(a);let m=null;if(t&&d.length>0){d.sort(((e,t)=>t.lineNumber-e.lineNumber)),m=[];for(let e=0,t=d.length;e0&&d[e-1].lineNumber===t)continue;const n=d[e].oldContent,r=this.getLineContent(t);0!==r.length&&r!==n&&-1===c.HG(r)&&m.push(t)}}return this._onDidChangeContent.fire(),new me.F4(g,f,m)}_reduceOperations(e){return e.length<1e3?e:[this._toSingleEditOperation(e)]}_toSingleEditOperation(e){let t=!1;const n=e[0].range,r=e[e.length-1].range,i=new m.Q(n.startLineNumber,n.startColumn,r.endLineNumber,r.endColumn);let s=n.startLineNumber,o=n.startColumn;const a=[];for(let u=0,g=e.length;u0&&a.push(n.text),s=r.endLineNumber,o=r.endColumn}const l=a.join(""),[c,h,d]=(0,u.W)(l);return{sortIndex:0,identifier:e[0].identifier,range:i,rangeOffset:this.getOffsetAt(i.startLineNumber,i.startColumn),rangeLength:this.getValueLengthInRange(i,0),text:l,eolCount:c,firstLineLength:h,lastLineLength:d,forceMoveMarkers:t,isAutoWhitespaceEdit:!1}}_doApplyEdits(e){e.sort(Hn._sortOpsDescending);const t=[];for(let n=0;n0){const e=o.eolCount+1;c=1===e?new m.Q(a,l,a,l+o.firstLineLength):new m.Q(a,l,a+e-1,o.lastLineLength+1)}else c=new m.Q(a,l,a,l);n=c.endLineNumber,r=c.endColumn,t.push(c),i=o}return t}static _sortOpsAscending(e,t){const n=m.Q.compareRangesUsingEnds(e.range,t.range);return 0===n?e.sortIndex-t.sortIndex:n}static _sortOpsDescending(e,t){const n=m.Q.compareRangesUsingEnds(e.range,t.range);return 0===n?t.sortIndex-e.sortIndex:-n}}class Kn{constructor(e,t,n,r,i,s,o,a,l){this._chunks=e,this._bom=t,this._cr=n,this._lf=r,this._crlf=i,this._containsRTL=s,this._containsUnusualLineTerminators=o,this._isBasicASCII=a,this._normalizeEOL=l}_getEOL(e){const t=this._cr+this._lf+this._crlf,n=this._cr+this._crlf;return 0===t?1===e?"\n":"\r\n":n>t/2?"\r\n":"\n"}create(e){const t=this._getEOL(e),n=this._chunks;if(this._normalizeEOL&&("\r\n"===t&&(this._cr>0||this._lf>0)||"\n"===t&&(this._cr>0||this._crlf>0)))for(let i=0,s=n.length;i=55296&&t<=56319?(this._acceptChunk1(e.substr(0,e.length-1),!1),this._hasPreviousChar=!0,this._previousChar=t):(this._acceptChunk1(e,!1),this._hasPreviousChar=!1,this._previousChar=t)}_acceptChunk1(e,t){(t||0!==e.length)&&(this._hasPreviousChar?this._acceptChunk2(String.fromCharCode(this._previousChar)+e):this._acceptChunk2(e))}_acceptChunk2(e){const t=function(e,t){e.length=0,e[0]=0;let n=1,r=0,i=0,s=0,o=!0;for(let l=0,c=t.length;l126)&&(o=!1)}const a=new Vn(Pn(e),r,i,s,o);return e.length=0,a}(this._tmpLineStarts,e);this.chunks.push(new qn(e,t.lineStarts)),this.cr+=t.cr,this.lf+=t.lf,this.crlf+=t.crlf,t.isBasicASCII||(this.isBasicASCII=!1,this.containsRTL||(this.containsRTL=c.E_(e)),this.containsUnusualLineTerminators||(this.containsUnusualLineTerminators=c.$X(e)))}finish(e=!0){return this._finish(),new Kn(this.chunks,this.BOM,this.cr,this.lf,this.crlf,this.containsRTL,this.containsUnusualLineTerminators,this.isBasicASCII,e)}_finish(){if(0===this.chunks.length&&this._acceptChunk1("",!0),this._hasPreviousChar){this._hasPreviousChar=!1;const e=this.chunks[this.chunks.length-1];e.buffer+=String.fromCharCode(this._previousChar);const t=zn(e.buffer);e.lineStarts=t,13===this._previousChar&&this.cr++}}}var Qn=n(6571),Jn=n(2083),Xn=n(1940),Yn=n(8381),Zn=n(4444);const er=new class{clone(){return this}equals(e){return this===e}};class tr{constructor(e){this._default=e,this._store=[]}get(e){return e=this._store.length;)this._store[this._store.length]=this._default;this._store[e]=t}replace(e,t,n){if(e>=this._store.length)return;if(0===t)return void this.insert(e,n);if(0===n)return void this.delete(e,t);const r=this._store.slice(0,e),i=this._store.slice(e+t),s=function(e,t){const n=[];for(let r=0;r=this._store.length||this._store.splice(e,t)}insert(e,t){if(0===t||e>=this._store.length)return;const n=[];for(let r=0;r0){const n=this._tokens[this._tokens.length-1];if(n.endLineNumber+1===e)return void n.appendLineTokens(t)}this._tokens.push(new nr(e,[t]))}finalize(){return this._tokens}}class ir{static{this.defaultTokenMetadata=33587200}static createEmpty(e,t){const n=ir.defaultTokenMetadata,r=new Uint32Array(2);return r[0]=e.length,r[1]=n,new ir(r,e,t)}static createFromTextAndMetadata(e,t){let n=0,r="";const i=new Array;for(const{text:s,metadata:o}of e)i.push(n+s.length,o),n+=s.length,r+=s;return new ir(new Uint32Array(i),r,t)}constructor(e,t,n){this._lineTokensBrand=void 0,this._tokens=e,this._tokensCount=this._tokens.length>>>1,this._text=t,this.languageIdCodec=n}equals(e){return e instanceof ir&&this.slicedEquals(e,0,this._tokensCount)}slicedEquals(e,t,n){if(this._text!==e._text)return!1;if(this._tokensCount!==e._tokensCount)return!1;const r=t<<1,i=r+(n<<1);for(let s=r;s0?this._tokens[e-1<<1]:0}getMetadata(e){return this._tokens[1+(e<<1)]}getLanguageId(e){const t=this._tokens[1+(e<<1)],n=Ye.x.getLanguageId(t);return this.languageIdCodec.decodeLanguageId(n)}getStandardTokenType(e){const t=this._tokens[1+(e<<1)];return Ye.x.getTokenType(t)}getForeground(e){const t=this._tokens[1+(e<<1)];return Ye.x.getForeground(t)}getClassName(e){const t=this._tokens[1+(e<<1)];return Ye.x.getClassNameFromMetadata(t)}getInlineStyle(e,t){const n=this._tokens[1+(e<<1)];return Ye.x.getInlineStyleFromMetadata(n,t)}getPresentation(e){const t=this._tokens[1+(e<<1)];return Ye.x.getPresentationFromMetadata(t)}getEndOffset(e){return this._tokens[e<<1]}findTokenIndexAtOffset(e){return ir.findIndexInTokensArray(this._tokens,e)}inflate(){return this}sliceAndInflate(e,t,n){return new sr(this,e,t,n)}static convertToEndOffset(e,t){const n=(e.length>>>1)-1;for(let r=0;r>>1)-1;for(;nt&&(r=i)}return n}withInserted(e){if(0===e.length)return this;let t=0,n=0,r="";const i=new Array;let s=0;for(;;){const o=ts){r+=this._text.substring(s,a.offset);const e=this._tokens[1+(t<<1)];i.push(r.length,e),s=a.offset}r+=a.text,i.push(r.length,a.tokenMetadata),n++}}return new ir(new Uint32Array(i),r,this.languageIdCodec)}getTokenText(e){const t=this.getStartOffset(e),n=this.getEndOffset(e);return this._text.substring(t,n)}forEach(e){const t=this.getCount();for(let n=0;n=n)break;this._tokensCount++}}getMetadata(e){return this._source.getMetadata(this._firstTokenIndex+e)}getLanguageId(e){return this._source.getLanguageId(this._firstTokenIndex+e)}getLineContent(){return this._source.getLineContent().substring(this._startOffset,this._endOffset)}equals(e){return e instanceof sr&&(this._startOffset===e._startOffset&&this._endOffset===e._endOffset&&this._deltaOffset===e._deltaOffset&&this._source.slicedEquals(e._source,this._firstTokenIndex,this._tokensCount))}getCount(){return this._tokensCount}getStandardTokenType(e){return this._source.getStandardTokenType(this._firstTokenIndex+e)}getForeground(e){return this._source.getForeground(this._firstTokenIndex+e)}getEndOffset(e){const t=this._source.getEndOffset(this._firstTokenIndex+e);return Math.min(this._endOffset,t)-this._startOffset+this._deltaOffset}getClassName(e){return this._source.getClassName(this._firstTokenIndex+e)}getInlineStyle(e,t){return this._source.getInlineStyle(this._firstTokenIndex+e,t)}getPresentation(e){return this._source.getPresentation(this._firstTokenIndex+e)}findTokenIndexAtOffset(e){return this._source.findTokenIndexAtOffset(e+this._startOffset-this._deltaOffset)-this._firstTokenIndex}getTokenText(e){const t=this._firstTokenIndex+e,n=this._source.getStartOffset(t),r=this._source.getEndOffset(t);let i=this._source.getTokenText(t);return nthis._endOffset&&(i=i.substring(0,i.length-(r-this._endOffset))),i}forEach(e){for(let t=0;tt)break;const i=this._textModel.getLineContent(r.lineNumber),s=ur(this._languageIdCodec,n,this.tokenizationSupport,i,!0,r.startState);e.add(r.lineNumber,s.tokens),this.store.setEndState(r.lineNumber,s.endState)}}getTokenTypeIfInsertingCharacter(e,t){const n=this.getStartState(e.lineNumber);if(!n)return 0;const r=this._textModel.getLanguageId(),i=this._textModel.getLineContent(e.lineNumber),s=i.substring(0,e.column-1)+t+i.substring(e.column-1),o=ur(this._languageIdCodec,r,this.tokenizationSupport,s,!0,n),a=new ir(o.tokens,s,this._languageIdCodec);if(0===a.getCount())return 0;const l=a.findTokenIndexAtOffset(e.column-1);return a.getStandardTokenType(l)}tokenizeLineWithEdit(e,t,n){const r=e.lineNumber,i=e.column,s=this.getStartState(r);if(!s)return null;const o=this._textModel.getLineContent(r),a=o.substring(0,i-1)+n+o.substring(i-1+t),l=this._textModel.getLanguageIdAtPosition(r,0),c=ur(this._languageIdCodec,l,this.tokenizationSupport,a,!0,s);return new ir(c.tokens,a,this._languageIdCodec)}hasAccurateTokensForLine(e){return e1&&o>=1;o--){const e=this._textModel.getLineFirstNonWhitespaceColumn(o);if(0!==e&&(e0&&n>0&&(n--,t--),this._lineEndStates.replace(e.startLineNumber,n,t)}}class hr{constructor(){this._ranges=[]}get min(){return 0===this._ranges.length?null:this._ranges[0].start}delete(e){const t=this._ranges.findIndex((t=>t.contains(e)));if(-1!==t){const n=this._ranges[t];n.start===e?n.endExclusive===e+1?this._ranges.splice(t,1):this._ranges[t]=new Zn.L(e+1,n.endExclusive):n.endExclusive===e+1?this._ranges[t]=new Zn.L(n.start,e):this._ranges.splice(t,1,new Zn.L(n.start,e),new Zn.L(e+1,n.endExclusive))}}addRange(e){Zn.L.addRange(e,this._ranges)}addRangeAndResize(e,t){let n=0;for(;!(n>=this._ranges.length||e.start<=this._ranges[n].endExclusive);)n++;let r=n;for(;!(r>=this._ranges.length||e.endExclusivee.toString())).join(" + ")}}function ur(e,t,n,r,i,s){let o=null;if(n)try{o=n.tokenizeEncoded(r,i,s.clone())}catch(a){(0,l.dz)(a)}return o||(o=function(e,t){const n=new Uint32Array(2);return n[0]=0,n[1]=(32768|e|2<<24)>>>0,new Jn.rY(n,null===t?er:t)}(e.encodeLanguageId(t),s)),ir.convertToEndOffset(o.tokens,r.length),o}class dr{constructor(e,t){this._tokenizerWithStateStore=e,this._backgroundTokenStore=t,this._isDisposed=!1,this._isScheduled=!1}dispose(){this._isDisposed=!0}handleChanges(){this._beginBackgroundTokenization()}_beginBackgroundTokenization(){!this._isScheduled&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._isScheduled=!0,(0,Xn.$6)((e=>{this._isScheduled=!1,this._backgroundTokenizeWithDeadline(e)})))}_backgroundTokenizeWithDeadline(e){const t=Date.now()+e.timeRemaining(),n=()=>{!this._isDisposed&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._backgroundTokenizeForAtLeast1ms(),Date.now()1)break;if(this._tokenizeOneInvalidLine(t)>=e)break}while(this._hasLinesToTokenize());this._backgroundTokenStore.setTokens(t.finalize()),this.checkFinished()}_hasLinesToTokenize(){return!!this._tokenizerWithStateStore&&!this._tokenizerWithStateStore.store.allStatesValid()}_tokenizeOneInvalidLine(e){const t=this._tokenizerWithStateStore?.getFirstInvalidLine();return t?(this._tokenizerWithStateStore.updateTokensUntilLine(e,t.lineNumber),t.lineNumber):this._tokenizerWithStateStore._textModel.getLineCount()+1}checkFinished(){this._isDisposed||this._tokenizerWithStateStore.store.allStatesValid()&&this._backgroundTokenStore.backgroundTokenizationFinished()}requestTokens(e,t){this._tokenizerWithStateStore.store.invalidateEndStateRange(new Qn.M(e,t))}}class gr{constructor(){this._onDidChangeVisibleRanges=new r.vl,this.onDidChangeVisibleRanges=this._onDidChangeVisibleRanges.event,this._views=new Set}attachView(){const e=new fr((t=>{this._onDidChangeVisibleRanges.fire({view:e,state:t})}));return this._views.add(e),e}detachView(e){this._views.delete(e),this._onDidChangeVisibleRanges.fire({view:e,state:void 0})}}class fr{constructor(e){this.handleStateChange=e}setVisibleLines(e,t){const n=e.map((e=>new Qn.M(e.startLineNumber,e.endLineNumber+1)));this.handleStateChange({visibleLineRanges:n,stabilized:t})}}class mr extends i.jG{get lineRanges(){return this._lineRanges}constructor(e){super(),this._refreshTokens=e,this.runner=this._register(new Xn.uC((()=>this.update()),50)),this._computedLineRanges=[],this._lineRanges=[]}update(){(0,o.aI)(this._computedLineRanges,this._lineRanges,((e,t)=>e.equals(t)))||(this._computedLineRanges=this._lineRanges,this._refreshTokens())}handleStateChange(e){this._lineRanges=e.visibleLineRanges,e.stabilized?(this.runner.cancel(),this.update()):this.runner.schedule()}}class pr extends i.jG{get backgroundTokenizationState(){return this._backgroundTokenizationState}constructor(e,t,n){super(),this._languageIdCodec=e,this._textModel=t,this.getLanguageId=n,this._backgroundTokenizationState=1,this._onDidChangeBackgroundTokenizationState=this._register(new r.vl),this.onDidChangeBackgroundTokenizationState=this._onDidChangeBackgroundTokenizationState.event,this._onDidChangeTokens=this._register(new r.vl),this.onDidChangeTokens=this._onDidChangeTokens.event}tokenizeIfCheap(e){this.isCheapToTokenize(e)&&this.forceTokenization(e)}}class br extends pr{constructor(e,t,n,r){super(t,n,r),this._treeSitterService=e,this._tokenizationSupport=null,this._initialize()}_initialize(){const e=this.getLanguageId();this._tokenizationSupport&&this._lastLanguageId===e||(this._lastLanguageId=e,this._tokenizationSupport=Jn.OB.get(e))}getLineTokens(e){const t=this._textModel.getLineContent(e);if(this._tokenizationSupport){const n=this._tokenizationSupport.tokenizeEncoded(e,this._textModel);if(n)return new ir(n,t,this._languageIdCodec)}return ir.createEmpty(t,this._languageIdCodec)}resetTokenization(e=!0){e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]}),this._initialize()}handleDidChangeAttached(){}handleDidChangeContent(e){e.isFlush&&this.resetTokenization(!1)}forceTokenization(e){}hasAccurateTokensForLine(e){return!0}isCheapToTokenize(e){return!0}getTokenTypeIfInsertingCharacter(e,t,n){return 0}tokenizeLineWithEdit(e,t,n){return null}get hasTokens(){return void 0!==this._treeSitterService.getParseResult(this._textModel)}}var _r=n(4432);const kr=new Uint32Array(0).buffer;class vr{static deleteBeginning(e,t){return null===e||e===kr?e:vr.delete(e,0,t)}static deleteEnding(e,t){if(null===e||e===kr)return e;const n=Cr(e),r=n[n.length-2];return vr.delete(e,t,r)}static delete(e,t,n){if(null===e||e===kr||t===n)return e;const r=Cr(e),i=r.length>>>1;if(0===t&&r[r.length-2]===n)return kr;const s=ir.findIndexInTokensArray(r,t),o=s>0?r[s-1<<1]:0;if(nl&&(r[a++]=e,r[a++]=r[1+(u<<1)],l=e)}if(a===r.length)return e;const h=new Uint32Array(a);return h.set(r.subarray(0,a),0),h.buffer}static append(e,t){if(t===kr)return e;if(e===kr)return t;if(null===e)return e;if(null===t)return null;const n=Cr(e),r=Cr(t),i=r.length>>>1,s=new Uint32Array(n.length+r.length);s.set(n,0);let o=n.length;const a=n[n.length-2];for(let l=0;l>>1;let s=ir.findIndexInTokensArray(r,t);if(s>0){r[s-1<<1]===t&&s--}for(let o=s;o0}getTokens(e,t,n){let r=null;if(t1&&(t=Ye.x.getLanguageId(r[1])!==e),!t)return kr}if(!r||0===r.length){const n=new Uint32Array(2);return n[0]=t,n[1]=Lr(e),n.buffer}return r[r.length-2]=t,0===r.byteOffset&&r.byteLength===r.buffer.byteLength?r.buffer:r}_ensureLine(e){for(;e>=this._len;)this._lineTokens[this._len]=null,this._len++}_deleteLines(e,t){0!==t&&(e+t>this._len&&(t=this._len-e),this._lineTokens.splice(e,t),this._len-=t)}_insertLines(e,t){if(0===t)return;const n=[];for(let r=0;r=this._len)return;if(e.startLineNumber===e.endLineNumber){if(e.startColumn===e.endColumn)return;return void(this._lineTokens[t]=vr.delete(this._lineTokens[t],e.startColumn-1,e.endColumn-1))}this._lineTokens[t]=vr.deleteEnding(this._lineTokens[t],e.startColumn-1);const n=e.endLineNumber-1;let r=null;n=this._len||(0!==t?(this._lineTokens[r]=vr.deleteEnding(this._lineTokens[r],e.column-1),this._lineTokens[r]=vr.insert(this._lineTokens[r],e.column-1,n),this._insertLines(e.lineNumber,t)):this._lineTokens[r]=vr.insert(this._lineTokens[r],e.column-1,n))}setMultilineTokens(e,t){if(0===e.length)return{changes:[]};const n=[];for(let r=0,i=e.length;r>>0}class wr{constructor(e){this._pieces=[],this._isComplete=!1,this._languageIdCodec=e}flush(){this._pieces=[],this._isComplete=!1}isEmpty(){return 0===this._pieces.length}set(e,t){this._pieces=e||[],this._isComplete=t}setPartial(e,t){let n=e;if(t.length>0){const r=t[0].getRange(),i=t[t.length-1].getRange();if(!r||!i)return e;n=e.plusRange(r).plusRange(i)}let r=null;for(let i=0,s=this._pieces.length;in.endLineNumber){r=r||{index:i};break}if(e.removeTokens(n),e.isEmpty()){this._pieces.splice(i,1),i--,s--;continue}if(e.endLineNumbern.endLineNumber){r=r||{index:i};continue}const[t,o]=e.split(n);t.isEmpty()?r=r||{index:i}:o.isEmpty()||(this._pieces.splice(i,1,t,o),i++,s++,r=r||{index:i})}return r=r||{index:this._pieces.length},t.length>0&&(this._pieces=o.nK(this._pieces,r.index,t)),n}isComplete(){return this._isComplete}addSparseTokens(e,t){if(0===t.getLineContent().length)return t;const n=this._pieces;if(0===n.length)return t;const r=n[wr._findFirstPieceWithLine(n,e)].getLineTokens(e);if(!r)return t;const i=t.getCount(),s=r.getCount();let o=0;const a=[];let l=0,c=0;const h=(e,t)=>{e!==c&&(c=e,a[l++]=e,a[l++]=t)};for(let u=0;u>>0,l=~a>>>0;for(;ot)){for(;i>n&&e[i-1].startLineNumber<=t&&t<=e[i-1].endLineNumber;)i--;return i}r=i-1}}return n}acceptEdit(e,t,n,r,i){for(const s of this._pieces)s.acceptEdit(e,t,n,r,i)}}var Sr,xr=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},Er=function(e,t){return function(n,r){t(n,r,e)}};let Nr=Sr=class extends Ut{constructor(e,t,n,s,o,a,l){super(),this._textModel=e,this._bracketPairsTextModelPart=t,this._languageId=n,this._attachedViews=s,this._languageService=o,this._languageConfigurationService=a,this._treeSitterService=l,this._semanticTokens=new wr(this._languageService.languageIdCodec),this._onDidChangeLanguage=this._register(new r.vl),this.onDidChangeLanguage=this._onDidChangeLanguage.event,this._onDidChangeLanguageConfiguration=this._register(new r.vl),this.onDidChangeLanguageConfiguration=this._onDidChangeLanguageConfiguration.event,this._onDidChangeTokens=this._register(new r.vl),this.onDidChangeTokens=this._onDidChangeTokens.event,this._tokensDisposables=this._register(new i.Cm),this._register(this._languageConfigurationService.onDidChange((e=>{e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}))),this._register(r.Jh.filter(Jn.OB.onDidChange,(e=>e.changedLanguages.includes(this._languageId)))((()=>{this.createPreferredTokenProvider()}))),this.createPreferredTokenProvider()}createGrammarTokens(){return this._register(new Tr(this._languageService.languageIdCodec,this._textModel,(()=>this._languageId),this._attachedViews))}createTreeSitterTokens(){return this._register(new br(this._treeSitterService,this._languageService.languageIdCodec,this._textModel,(()=>this._languageId)))}createTokens(e){const t=void 0!==this._tokens;this._tokens?.dispose(),this._tokens=e?this.createTreeSitterTokens():this.createGrammarTokens(),this._tokensDisposables.clear(),this._tokensDisposables.add(this._tokens.onDidChangeTokens((e=>{this._emitModelTokensChangedEvent(e)}))),this._tokensDisposables.add(this._tokens.onDidChangeBackgroundTokenizationState((e=>{this._bracketPairsTextModelPart.handleDidChangeBackgroundTokenizationState()}))),t&&this._tokens.resetTokenization()}createPreferredTokenProvider(){Jn.OB.get(this._languageId)?this._tokens instanceof br||this.createTokens(!0):this._tokens instanceof Tr||this.createTokens(!1)}handleLanguageConfigurationServiceChange(e){e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}handleDidChangeContent(e){if(e.isFlush)this._semanticTokens.flush();else if(!e.isEolChange)for(const t of e.changes){const[e,n,r]=(0,u.W)(t.text);this._semanticTokens.acceptEdit(t.range,e,n,r,t.text.length>0?t.text.charCodeAt(0):0)}this._tokens.handleDidChangeContent(e)}handleDidChangeAttached(){this._tokens.handleDidChangeAttached()}getLineTokens(e){this.validateLineNumber(e);const t=this._tokens.getLineTokens(e);return this._semanticTokens.addSparseTokens(e,t)}_emitModelTokensChangedEvent(e){this._textModel._isDisposing()||(this._bracketPairsTextModelPart.handleDidChangeTokens(e),this._onDidChangeTokens.fire(e))}validateLineNumber(e){if(e<1||e>this._textModel.getLineCount())throw new l.D7("Illegal value for lineNumber")}get hasTokens(){return this._tokens.hasTokens}resetTokenization(){this._tokens.resetTokenization()}get backgroundTokenizationState(){return this._tokens.backgroundTokenizationState}forceTokenization(e){this.validateLineNumber(e),this._tokens.forceTokenization(e)}hasAccurateTokensForLine(e){return this.validateLineNumber(e),this._tokens.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return this.validateLineNumber(e),this._tokens.isCheapToTokenize(e)}tokenizeIfCheap(e){this.validateLineNumber(e),this._tokens.tokenizeIfCheap(e)}getTokenTypeIfInsertingCharacter(e,t,n){return this._tokens.getTokenTypeIfInsertingCharacter(e,t,n)}tokenizeLineWithEdit(e,t,n){return this._tokens.tokenizeLineWithEdit(e,t,n)}setSemanticTokens(e,t){this._semanticTokens.set(e,t),this._emitModelTokensChangedEvent({semanticTokensApplied:null!==e,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]})}hasCompleteSemanticTokens(){return this._semanticTokens.isComplete()}hasSomeSemanticTokens(){return!this._semanticTokens.isEmpty()}setPartialSemanticTokens(e,t){if(this.hasCompleteSemanticTokens())return;const n=this._textModel.validateRange(this._semanticTokens.setPartial(e,t));this._emitModelTokensChangedEvent({semanticTokensApplied:!0,ranges:[{fromLineNumber:n.startLineNumber,toLineNumber:n.endLineNumber}]})}getWordAtPosition(e){this.assertNotDisposed();const t=this._textModel.validatePosition(e),n=this._textModel.getLineContent(t.lineNumber),r=this.getLineTokens(t.lineNumber),i=r.findTokenIndexAtOffset(t.column-1),[s,o]=Sr._findLanguageBoundaries(r,i),a=(0,v.Th)(t.column,this.getLanguageConfiguration(r.getLanguageId(i)).getWordDefinition(),n.substring(s,o),s);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a;if(i>0&&s===t.column-1){const[s,o]=Sr._findLanguageBoundaries(r,i-1),a=(0,v.Th)(t.column,this.getLanguageConfiguration(r.getLanguageId(i-1)).getWordDefinition(),n.substring(s,o),s);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a}return null}getLanguageConfiguration(e){return this._languageConfigurationService.getLanguageConfiguration(e)}static _findLanguageBoundaries(e,t){const n=e.getLanguageId(t);let r=0;for(let s=t;s>=0&&e.getLanguageId(s)===n;s--)r=e.getStartOffset(s);let i=e.getLineContent().length;for(let s=t,o=e.getCount();s{const t=this.getLanguageId();-1!==e.changedLanguages.indexOf(t)&&this.resetTokenization()}))),this.resetTokenization(),this._register(r.onDidChangeVisibleRanges((({view:e,state:t})=>{if(t){let n=this._attachedViewStates.get(e);n||(n=new mr((()=>this.refreshRanges(n.lineRanges))),this._attachedViewStates.set(e,n)),n.handleStateChange(t)}else this._attachedViewStates.deleteAndDispose(e)})))}resetTokenization(e=!0){this._tokens.flush(),this._debugBackgroundTokens?.flush(),this._debugBackgroundStates&&(this._debugBackgroundStates=new lr(this._textModel.getLineCount())),e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]});const[t,n]=(()=>{if(this._textModel.isTooLargeForTokenization())return[null,null];const e=Jn.dG.get(this.getLanguageId());if(!e)return[null,null];let t;try{t=e.getInitialState()}catch(n){return(0,l.dz)(n),[null,null]}return[e,t]})();if(this._tokenizer=t&&n?new ar(this._textModel.getLineCount(),t,this._textModel,this._languageIdCodec):null,this._backgroundTokenizer.clear(),this._defaultBackgroundTokenizer=null,this._tokenizer){const e={setTokens:e=>{this.setTokens(e)},backgroundTokenizationFinished:()=>{if(2===this._backgroundTokenizationState)return;this._backgroundTokenizationState=2,this._onDidChangeBackgroundTokenizationState.fire()},setEndState:(e,t)=>{if(!this._tokenizer)return;const n=this._tokenizer.store.getFirstInvalidEndStateLineNumber();null!==n&&e>=n&&this._tokenizer?.store.setEndState(e,t)}};t&&t.createBackgroundTokenizer&&!t.backgroundTokenizerShouldOnlyVerifyTokens&&(this._backgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,e)),this._backgroundTokenizer.value||this._textModel.isTooLargeForTokenization()||(this._backgroundTokenizer.value=this._defaultBackgroundTokenizer=new dr(this._tokenizer,e),this._defaultBackgroundTokenizer.handleChanges()),t?.backgroundTokenizerShouldOnlyVerifyTokens&&t.createBackgroundTokenizer?(this._debugBackgroundTokens=new yr(this._languageIdCodec),this._debugBackgroundStates=new lr(this._textModel.getLineCount()),this._debugBackgroundTokenizer.clear(),this._debugBackgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,{setTokens:e=>{this._debugBackgroundTokens?.setMultilineTokens(e,this._textModel)},backgroundTokenizationFinished(){},setEndState:(e,t)=>{this._debugBackgroundStates?.setEndState(e,t)}})):(this._debugBackgroundTokens=void 0,this._debugBackgroundStates=void 0,this._debugBackgroundTokenizer.value=void 0)}this.refreshAllVisibleLineTokens()}handleDidChangeAttached(){this._defaultBackgroundTokenizer?.handleChanges()}handleDidChangeContent(e){if(e.isFlush)this.resetTokenization(!1);else if(!e.isEolChange){for(const t of e.changes){const[e,n]=(0,u.W)(t.text);this._tokens.acceptEdit(t.range,e,n),this._debugBackgroundTokens?.acceptEdit(t.range,e,n)}this._debugBackgroundStates?.acceptChanges(e.changes),this._tokenizer&&this._tokenizer.store.acceptChanges(e.changes),this._defaultBackgroundTokenizer?.handleChanges()}}setTokens(e){const{changes:t}=this._tokens.setMultilineTokens(e,this._textModel);return t.length>0&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:t}),{changes:t}}refreshAllVisibleLineTokens(){const e=Qn.M.joinMany([...this._attachedViewStates].map((([e,t])=>t.lineRanges)));this.refreshRanges(e)}refreshRanges(e){for(const t of e)this.refreshRange(t.startLineNumber,t.endLineNumberExclusive-1)}refreshRange(e,t){if(!this._tokenizer)return;e=Math.max(1,Math.min(this._textModel.getLineCount(),e)),t=Math.min(this._textModel.getLineCount(),t);const n=new rr,{heuristicTokens:r}=this._tokenizer.tokenizeHeuristically(n,e,t),i=this.setTokens(n.finalize());if(r)for(const s of i.changes)this._backgroundTokenizer.value?.requestTokens(s.fromLineNumber,s.toLineNumber+1);this._defaultBackgroundTokenizer?.checkFinished()}forceTokenization(e){const t=new rr;this._tokenizer?.updateTokensUntilLine(t,e),this.setTokens(t.finalize()),this._defaultBackgroundTokenizer?.checkFinished()}hasAccurateTokensForLine(e){return!this._tokenizer||this._tokenizer.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return!this._tokenizer||this._tokenizer.isCheapToTokenize(e)}getLineTokens(e){const t=this._textModel.getLineContent(e),n=this._tokens.getTokens(this._textModel.getLanguageId(),e-1,t);if(this._debugBackgroundTokens&&this._debugBackgroundStates&&this._tokenizer&&this._debugBackgroundStates.getFirstInvalidEndStateLineNumberOrMax()>e&&this._tokenizer.store.getFirstInvalidEndStateLineNumberOrMax()>e){const r=this._debugBackgroundTokens.getTokens(this._textModel.getLanguageId(),e-1,t);!n.equals(r)&&this._debugBackgroundTokenizer.value?.reportMismatchingTokens&&this._debugBackgroundTokenizer.value.reportMismatchingTokens(e)}return n}getTokenTypeIfInsertingCharacter(e,t,n){if(!this._tokenizer)return 0;const r=this._textModel.validatePosition(new f.y(e,t));return this.forceTokenization(r.lineNumber),this._tokenizer.getTokenTypeIfInsertingCharacter(r,n)}tokenizeLineWithEdit(e,t,n){if(!this._tokenizer)return null;const r=this._textModel.validatePosition(e);return this.forceTokenization(r.lineNumber),this._tokenizer.tokenizeLineWithEdit(r,t,n)}get hasTokens(){return this._tokens.hasTokens}}class Ar{constructor(){this.changeType=1}}class Ir{static applyInjectedText(e,t){if(!t||0===t.length)return e;let n="",r=0;for(const i of t)n+=e.substring(r,i.column-1),r=i.column-1,n+=i.options.content;return n+=e.substring(r),n}static fromDecorations(e){const t=[];for(const n of e)n.options.before&&n.options.before.content.length>0&&t.push(new Ir(n.ownerId,n.range.startLineNumber,n.range.startColumn,n.options.before,0)),n.options.after&&n.options.after.content.length>0&&t.push(new Ir(n.ownerId,n.range.endLineNumber,n.range.endColumn,n.options.after,1));return t.sort(((e,t)=>e.lineNumber===t.lineNumber?e.column===t.column?e.order-t.order:e.column-t.column:e.lineNumber-t.lineNumber)),t}constructor(e,t,n,r,i){this.ownerId=e,this.lineNumber=t,this.column=n,this.options=r,this.order=i}}class Or{constructor(e,t,n){this.changeType=2,this.lineNumber=e,this.detail=t,this.injectedText=n}}class Mr{constructor(e,t){this.changeType=3,this.fromLineNumber=e,this.toLineNumber=t}}class Rr{constructor(e,t,n,r){this.changeType=4,this.injectedTexts=r,this.fromLineNumber=e,this.toLineNumber=t,this.detail=n}}class Dr{constructor(){this.changeType=5}}class Br{constructor(e,t,n,r){this.changes=e,this.versionId=t,this.isUndoing=n,this.isRedoing=r,this.resultingSelection=null}containsEvent(e){for(let t=0,n=this.changes.length;t=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},Ur=function(e,t){return function(n,r){t(n,r,e)}};function $r(e,t){let n;return n="string"===typeof e?function(e){const t=new Gn;return t.acceptChunk(e),t.finish()}(e):me.nk(e)?function(e){const t=new Gn;let n;for(;"string"===typeof(n=e.read());)t.acceptChunk(n);return t.finish()}(e):e,n.create(t)}let Hr=0;class Kr{constructor(e){this._source=e,this._eos=!1}read(){if(this._eos)return null;const e=[];let t=0,n=0;for(;;){const r=this._source.read();if(null===r)return this._eos=!0,0===t?null:e.join("");if(r.length>0&&(e[t++]=r,n+=r.length),n>=65536)return e.join("")}}}const Gr=()=>{throw new Error("Invalid change accessor")};let Qr=class extends i.jG{static{qr=this}static{this._MODEL_SYNC_LIMIT=52428800}static{this.LARGE_FILE_SIZE_THRESHOLD=20971520}static{this.LARGE_FILE_LINE_COUNT_THRESHOLD=3e5}static{this.LARGE_FILE_HEAP_OPERATION_THRESHOLD=268435456}static{this.DEFAULT_CREATION_OPTIONS={isForSimpleWidget:!1,tabSize:b.tabSize,indentSize:b.indentSize,insertSpaces:b.insertSpaces,detectIndentation:!1,defaultEOL:1,trimAutoWhitespace:b.trimAutoWhitespace,largeFileOptimizations:b.largeFileOptimizations,bracketPairColorizationOptions:b.bracketPairColorizationOptions}}static resolveOptions(e,t){if(t.detectIndentation){const n=Xt(e,t.tabSize,t.insertSpaces);return new me.X2({tabSize:n.tabSize,indentSize:"tabSize",insertSpaces:n.insertSpaces,trimAutoWhitespace:t.trimAutoWhitespace,defaultEOL:t.defaultEOL,bracketPairColorizationOptions:t.bracketPairColorizationOptions})}return new me.X2(t)}get onDidChangeLanguage(){return this._tokenizationTextModelPart.onDidChangeLanguage}get onDidChangeLanguageConfiguration(){return this._tokenizationTextModelPart.onDidChangeLanguageConfiguration}get onDidChangeTokens(){return this._tokenizationTextModelPart.onDidChangeTokens}onDidChangeContent(e){return this._eventEmitter.slowEvent((t=>e(t.contentChangedEvent)))}onDidChangeContentOrInjectedText(e){return(0,i.qE)(this._eventEmitter.fastEvent((t=>e(t))),this._onDidChangeInjectedText.event((t=>e(t))))}_isDisposing(){return this.__isDisposing}get tokenization(){return this._tokenizationTextModelPart}get bracketPairs(){return this._bracketPairs}get guides(){return this._guidesTextModelPart}constructor(e,t,n,s=null,o,a,l,u){super(),this._undoRedoService=o,this._languageService=a,this._languageConfigurationService=l,this.instantiationService=u,this._onWillDispose=this._register(new r.vl),this.onWillDispose=this._onWillDispose.event,this._onDidChangeDecorations=this._register(new li((e=>this.handleBeforeFireDecorationsChangedEvent(e)))),this.onDidChangeDecorations=this._onDidChangeDecorations.event,this._onDidChangeOptions=this._register(new r.vl),this.onDidChangeOptions=this._onDidChangeOptions.event,this._onDidChangeAttached=this._register(new r.vl),this.onDidChangeAttached=this._onDidChangeAttached.event,this._onDidChangeInjectedText=this._register(new r.vl),this._eventEmitter=this._register(new ci),this._languageSelectionListener=this._register(new i.HE),this._deltaDecorationCallCnt=0,this._attachedViews=new gr,Hr++,this.id="$model"+Hr,this.isForSimpleWidget=n.isForSimpleWidget,this._associatedResource="undefined"===typeof s||null===s?h.r.parse("inmemory://model/"+Hr):s,this._attachedEditorCount=0;const{textBuffer:d,disposable:g}=$r(e,n.defaultEOL);this._buffer=d,this._bufferDisposable=g,this._options=qr.resolveOptions(this._buffer,n);const f="string"===typeof t?t:t.languageId;"string"!==typeof t&&(this._languageSelectionListener.value=t.onDidChange((()=>this._setLanguage(t.languageId)))),this._bracketPairs=this._register(new yt(this,this._languageConfigurationService)),this._guidesTextModelPart=this._register(new Kt(this,this._languageConfigurationService)),this._decorationProvider=this._register(new Nt(this)),this._tokenizationTextModelPart=this.instantiationService.createInstance(Nr,this,this._bracketPairs,f,this._attachedViews);const p=this._buffer.getLineCount(),b=this._buffer.getValueLengthInRange(new m.Q(1,1,p,this._buffer.getLineLength(p)+1),0);n.largeFileOptimizations?(this._isTooLargeForTokenization=b>qr.LARGE_FILE_SIZE_THRESHOLD||p>qr.LARGE_FILE_LINE_COUNT_THRESHOLD,this._isTooLargeForHeapOperation=b>qr.LARGE_FILE_HEAP_OPERATION_THRESHOLD):(this._isTooLargeForTokenization=!1,this._isTooLargeForHeapOperation=!1),this._isTooLargeForSyncing=b>qr._MODEL_SYNC_LIMIT,this._versionId=1,this._alternativeVersionId=1,this._initialUndoRedoSnapshot=null,this._isDisposed=!1,this.__isDisposing=!1,this._instanceId=c.tk(Hr),this._lastDecorationId=0,this._decorations=Object.create(null),this._decorationsTree=new Yr,this._commandManager=new jt(this,this._undoRedoService),this._isUndoing=!1,this._isRedoing=!1,this._trimAutoWhitespaceLines=null,this._register(this._decorationProvider.onDidChange((()=>{this._onDidChangeDecorations.beginDeferredEmit(),this._onDidChangeDecorations.fire(),this._onDidChangeDecorations.endDeferredEmit()}))),this._languageService.requestRichLanguageFeatures(f),this._register(this._languageConfigurationService.onDidChange((e=>{this._bracketPairs.handleLanguageConfigurationServiceChange(e),this._tokenizationTextModelPart.handleLanguageConfigurationServiceChange(e)})))}dispose(){this.__isDisposing=!0,this._onWillDispose.fire(),this._tokenizationTextModelPart.dispose(),this._isDisposed=!0,super.dispose(),this._bufferDisposable.dispose(),this.__isDisposing=!1;const e=new Hn([],"","\n",!1,!1,!0,!0);e.dispose(),this._buffer=e,this._bufferDisposable=i.jG.None}_assertNotDisposed(){if(this._isDisposed)throw new l.D7("Model is disposed!")}_emitContentChangedEvent(e,t){this.__isDisposing||(this._tokenizationTextModelPart.handleDidChangeContent(t),this._bracketPairs.handleDidChangeContent(t),this._eventEmitter.fire(new Pr(e,t)))}setValue(e){if(this._assertNotDisposed(),null===e||void 0===e)throw(0,l.Qg)();const{textBuffer:t,disposable:n}=$r(e,this._options.defaultEOL);this._setValueFromTextBuffer(t,n)}_createContentChanged2(e,t,n,r,i,s,o,a){return{changes:[{range:e,rangeOffset:t,rangeLength:n,text:r}],eol:this._buffer.getEOL(),isEolChange:a,versionId:this.getVersionId(),isUndoing:i,isRedoing:s,isFlush:o}}_setValueFromTextBuffer(e,t){this._assertNotDisposed();const n=this.getFullModelRange(),r=this.getValueLengthInRange(n),i=this.getLineCount(),s=this.getLineMaxColumn(i);this._buffer=e,this._bufferDisposable.dispose(),this._bufferDisposable=t,this._increaseVersionId(),this._decorations=Object.create(null),this._decorationsTree=new Yr,this._commandManager.clear(),this._trimAutoWhitespaceLines=null,this._emitContentChangedEvent(new Br([new Ar],this._versionId,!1,!1),this._createContentChanged2(new m.Q(1,1,i,s),0,r,this.getValue(),!1,!1,!0,!1))}setEOL(e){this._assertNotDisposed();const t=1===e?"\r\n":"\n";if(this._buffer.getEOL()===t)return;const n=this.getFullModelRange(),r=this.getValueLengthInRange(n),i=this.getLineCount(),s=this.getLineMaxColumn(i);this._onBeforeEOLChange(),this._buffer.setEOL(t),this._increaseVersionId(),this._onAfterEOLChange(),this._emitContentChangedEvent(new Br([new Dr],this._versionId,!1,!1),this._createContentChanged2(new m.Q(1,1,i,s),0,r,this.getValue(),!1,!1,!1,!0))}_onBeforeEOLChange(){this._decorationsTree.ensureAllNodesHaveRanges(this)}_onAfterEOLChange(){const e=this.getVersionId(),t=this._decorationsTree.collectNodesPostOrder();for(let n=0,r=t.length;n0}getAttachedEditorCount(){return this._attachedEditorCount}isTooLargeForSyncing(){return this._isTooLargeForSyncing}isTooLargeForTokenization(){return this._isTooLargeForTokenization}isTooLargeForHeapOperation(){return this._isTooLargeForHeapOperation}isDisposed(){return this._isDisposed}isDominatedByLongLines(){if(this._assertNotDisposed(),this.isTooLargeForTokenization())return!1;let e=0,t=0;const n=this._buffer.getLineCount();for(let r=1;r<=n;r++){const n=this._buffer.getLineLength(r);n>=1e4?t+=n:e+=n}return t>e}get uri(){return this._associatedResource}getOptions(){return this._assertNotDisposed(),this._options}getFormattingOptions(){return{tabSize:this._options.indentSize,insertSpaces:this._options.insertSpaces}}updateOptions(e){this._assertNotDisposed();const t="undefined"!==typeof e.tabSize?e.tabSize:this._options.tabSize,n="undefined"!==typeof e.indentSize?e.indentSize:this._options.originalIndentSize,r="undefined"!==typeof e.insertSpaces?e.insertSpaces:this._options.insertSpaces,i="undefined"!==typeof e.trimAutoWhitespace?e.trimAutoWhitespace:this._options.trimAutoWhitespace,s="undefined"!==typeof e.bracketColorizationOptions?e.bracketColorizationOptions:this._options.bracketPairColorizationOptions,o=new me.X2({tabSize:t,indentSize:n,insertSpaces:r,defaultEOL:this._options.defaultEOL,trimAutoWhitespace:i,bracketPairColorizationOptions:s});if(this._options.equals(o))return;const a=this._options.createChangeEvent(o);this._options=o,this._bracketPairs.handleDidChangeOptions(a),this._decorationProvider.handleDidChangeOptions(a),this._onDidChangeOptions.fire(a)}detectIndentation(e,t){this._assertNotDisposed();const n=Xt(this._buffer,t,e);this.updateOptions({insertSpaces:n.insertSpaces,tabSize:n.tabSize,indentSize:n.tabSize})}normalizeIndentation(e){return this._assertNotDisposed(),g(e,this._options.indentSize,this._options.insertSpaces)}getVersionId(){return this._assertNotDisposed(),this._versionId}mightContainRTL(){return this._buffer.mightContainRTL()}mightContainUnusualLineTerminators(){return this._buffer.mightContainUnusualLineTerminators()}removeUnusualLineTerminators(e=null){const t=this.findMatches(c._J.source,!1,!0,!1,null,!1,1073741824);this._buffer.resetMightContainUnusualLineTerminators(),this.pushEditOperations(e,t.map((e=>({range:e.range,text:null}))),(()=>null))}mightContainNonBasicASCII(){return this._buffer.mightContainNonBasicASCII()}getAlternativeVersionId(){return this._assertNotDisposed(),this._alternativeVersionId}getInitialUndoRedoSnapshot(){return this._assertNotDisposed(),this._initialUndoRedoSnapshot}getOffsetAt(e){this._assertNotDisposed();const t=this._validatePosition(e.lineNumber,e.column,0);return this._buffer.getOffsetAt(t.lineNumber,t.column)}getPositionAt(e){this._assertNotDisposed();const t=Math.min(this._buffer.getLength(),Math.max(0,e));return this._buffer.getPositionAt(t)}_increaseVersionId(){this._versionId=this._versionId+1,this._alternativeVersionId=this._versionId}_overwriteVersionId(e){this._versionId=e}_overwriteAlternativeVersionId(e){this._alternativeVersionId=e}_overwriteInitialUndoRedoSnapshot(e){this._initialUndoRedoSnapshot=e}getValue(e,t=!1){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new l.D7("Operation would exceed heap memory limits");const n=this.getFullModelRange(),r=this.getValueInRange(n,e);return t?this._buffer.getBOM()+r:r}createSnapshot(e=!1){return new Kr(this._buffer.createSnapshot(e))}getValueLength(e,t=!1){this._assertNotDisposed();const n=this.getFullModelRange(),r=this.getValueLengthInRange(n,e);return t?this._buffer.getBOM().length+r:r}getValueInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueInRange(this.validateRange(e),t)}getValueLengthInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueLengthInRange(this.validateRange(e),t)}getCharacterCountInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getCharacterCountInRange(this.validateRange(e),t)}getLineCount(){return this._assertNotDisposed(),this._buffer.getLineCount()}getLineContent(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineContent(e)}getLineLength(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)}getLinesContent(){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new l.D7("Operation would exceed heap memory limits");return this._buffer.getLinesContent()}getEOL(){return this._assertNotDisposed(),this._buffer.getEOL()}getEndOfLineSequence(){return this._assertNotDisposed(),"\n"===this._buffer.getEOL()?0:1}getLineMinColumn(e){return this._assertNotDisposed(),1}getLineMaxColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)+1}getLineFirstNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineFirstNonWhitespaceColumn(e)}getLineLastNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineLastNonWhitespaceColumn(e)}_validateRangeRelaxedNoAllocations(e){const t=this._buffer.getLineCount(),n=e.startLineNumber,r=e.startColumn;let i=Math.floor("number"!==typeof n||isNaN(n)?1:n),s=Math.floor("number"!==typeof r||isNaN(r)?1:r);if(i<1)i=1,s=1;else if(i>t)i=t,s=this.getLineMaxColumn(i);else if(s<=1)s=1;else{const e=this.getLineMaxColumn(i);s>=e&&(s=e)}const o=e.endLineNumber,a=e.endColumn;let l=Math.floor("number"!==typeof o||isNaN(o)?1:o),c=Math.floor("number"!==typeof a||isNaN(a)?1:a);if(l<1)l=1,c=1;else if(l>t)l=t,c=this.getLineMaxColumn(l);else if(c<=1)c=1;else{const e=this.getLineMaxColumn(l);c>=e&&(c=e)}return n===i&&r===s&&o===l&&a===c&&e instanceof m.Q&&!(e instanceof p.L)?e:new m.Q(i,s,l,c)}_isValidPosition(e,t,n){if("number"!==typeof e||"number"!==typeof t)return!1;if(isNaN(e)||isNaN(t))return!1;if(e<1||t<1)return!1;if((0|e)!==e||(0|t)!==t)return!1;if(e>this._buffer.getLineCount())return!1;if(1===t)return!0;if(t>this.getLineMaxColumn(e))return!1;if(1===n){const n=this._buffer.getLineCharCode(e,t-2);if(c.pc(n))return!1}return!0}_validatePosition(e,t,n){const r=Math.floor("number"!==typeof e||isNaN(e)?1:e),i=Math.floor("number"!==typeof t||isNaN(t)?1:t),s=this._buffer.getLineCount();if(r<1)return new f.y(1,1);if(r>s)return new f.y(s,this.getLineMaxColumn(s));if(i<=1)return new f.y(r,1);const o=this.getLineMaxColumn(r);if(i>=o)return new f.y(r,o);if(1===n){const e=this._buffer.getLineCharCode(r,i-2);if(c.pc(e))return new f.y(r,i-1)}return new f.y(r,i)}validatePosition(e){return this._assertNotDisposed(),e instanceof f.y&&this._isValidPosition(e.lineNumber,e.column,1)?e:this._validatePosition(e.lineNumber,e.column,1)}_isValidRange(e,t){const n=e.startLineNumber,r=e.startColumn,i=e.endLineNumber,s=e.endColumn;if(!this._isValidPosition(n,r,0))return!1;if(!this._isValidPosition(i,s,0))return!1;if(1===t){const e=r>1?this._buffer.getLineCharCode(n,r-2):0,t=s>1&&s<=this._buffer.getLineLength(i)?this._buffer.getLineCharCode(i,s-2):0,o=c.pc(e),a=c.pc(t);return!o&&!a}return!0}validateRange(e){if(this._assertNotDisposed(),e instanceof m.Q&&!(e instanceof p.L)&&this._isValidRange(e,1))return e;const t=this._validatePosition(e.startLineNumber,e.startColumn,0),n=this._validatePosition(e.endLineNumber,e.endColumn,0),r=t.lineNumber,i=t.column,s=n.lineNumber,o=n.column;{const e=i>1?this._buffer.getLineCharCode(r,i-2):0,t=o>1&&o<=this._buffer.getLineLength(s)?this._buffer.getLineCharCode(s,o-2):0,n=c.pc(e),a=c.pc(t);return n||a?r===s&&i===o?new m.Q(r,i-1,s,o-1):n&&a?new m.Q(r,i-1,s,o+1):n?new m.Q(r,i-1,s,o):new m.Q(r,i,s,o+1):new m.Q(r,i,s,o)}}modifyPosition(e,t){this._assertNotDisposed();const n=this.getOffsetAt(e)+t;return this.getPositionAt(Math.min(this._buffer.getLength(),Math.max(0,n)))}getFullModelRange(){this._assertNotDisposed();const e=this.getLineCount();return new m.Q(1,1,e,this.getLineMaxColumn(e))}findMatchesLineByLine(e,t,n,r){return this._buffer.findMatchesLineByLine(e,t,n,r)}findMatches(e,t,n,r,i,s,o=999){this._assertNotDisposed();let a=null;null!==t&&(Array.isArray(t)||(t=[t]),t.every((e=>m.Q.isIRange(e)))&&(a=t.map((e=>this.validateRange(e))))),null===a&&(a=[this.getFullModelRange()]),a=a.sort(((e,t)=>e.startLineNumber-t.startLineNumber||e.startColumn-t.startColumn));const l=[];let c;if(l.push(a.reduce(((e,t)=>m.Q.areIntersecting(e,t)?e.plusRange(t):(l.push(e),t)))),!n&&e.indexOf("\n")<0){const t=new Bn.lt(e,n,r,i).parseSearchRequest();if(!t)return[];c=e=>this.findMatchesLineByLine(e,t,s,o)}else c=t=>Bn.hB.findMatches(this,new Bn.lt(e,n,r,i),t,s,o);return l.map(c).reduce(((e,t)=>e.concat(t)),[])}findNextMatch(e,t,n,r,i,s){this._assertNotDisposed();const o=this.validatePosition(t);if(!n&&e.indexOf("\n")<0){const t=new Bn.lt(e,n,r,i).parseSearchRequest();if(!t)return null;const a=this.getLineCount();let l=new m.Q(o.lineNumber,o.column,a,this.getLineMaxColumn(a)),c=this.findMatchesLineByLine(l,t,s,1);return Bn.hB.findNextMatch(this,new Bn.lt(e,n,r,i),o,s),c.length>0?c[0]:(l=new m.Q(1,1,o.lineNumber,this.getLineMaxColumn(o.lineNumber)),c=this.findMatchesLineByLine(l,t,s,1),c.length>0?c[0]:null)}return Bn.hB.findNextMatch(this,new Bn.lt(e,n,r,i),o,s)}findPreviousMatch(e,t,n,r,i,s){this._assertNotDisposed();const o=this.validatePosition(t);return Bn.hB.findPreviousMatch(this,new Bn.lt(e,n,r,i),o,s)}pushStackElement(){this._commandManager.pushStackElement()}popStackElement(){this._commandManager.popStackElement()}pushEOL(e){if(("\n"===this.getEOL()?0:1)!==e)try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEOL(e)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_validateEditOperation(e){return e instanceof me.Wo?e:new me.Wo(e.identifier||null,this.validateRange(e.range),e.text,e.forceMoveMarkers||!1,e.isAutoWhitespaceEdit||!1,e._isTracked||!1)}_validateEditOperations(e){const t=[];for(let n=0,r=e.length;n({range:this.validateRange(e.range),text:e.text})));let r=!0;if(e)for(let t=0,i=e.length;ti.endLineNumber,o=i.startLineNumber>t.endLineNumber;if(!r&&!o){s=!0;break}}if(!s){r=!1;break}}if(r)for(let e=0,i=this._trimAutoWhitespaceLines.length;et.endLineNumber)&&(!(r===t.startLineNumber&&t.startColumn===i&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(0))&&!(r===t.startLineNumber&&1===t.startColumn&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(o.length-1)))){s=!1;break}}if(s){const e=new m.Q(r,1,r,i);t.push(new me.Wo(null,e,null,!1,!1,!1))}}this._trimAutoWhitespaceLines=null}return null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEditOperation(e,t,n,r)}_applyUndo(e,t,n,r){const i=e.map((e=>{const t=this.getPositionAt(e.newPosition),n=this.getPositionAt(e.newEnd);return{range:new m.Q(t.lineNumber,t.column,n.lineNumber,n.column),text:e.oldText}}));this._applyUndoRedoEdits(i,t,!0,!1,n,r)}_applyRedo(e,t,n,r){const i=e.map((e=>{const t=this.getPositionAt(e.oldPosition),n=this.getPositionAt(e.oldEnd);return{range:new m.Q(t.lineNumber,t.column,n.lineNumber,n.column),text:e.newText}}));this._applyUndoRedoEdits(i,t,!1,!0,n,r)}_applyUndoRedoEdits(e,t,n,r,i,s){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),this._isUndoing=n,this._isRedoing=r,this.applyEdits(e,!1),this.setEOL(t),this._overwriteAlternativeVersionId(i)}finally{this._isUndoing=!1,this._isRedoing=!1,this._eventEmitter.endDeferredEmit(s),this._onDidChangeDecorations.endDeferredEmit()}}applyEdits(e,t=!1){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit();const n=this._validateEditOperations(e);return this._doApplyEdits(n,t)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_doApplyEdits(e,t){const n=this._buffer.getLineCount(),r=this._buffer.applyEdits(e,this._options.trimAutoWhitespace,t),i=this._buffer.getLineCount(),s=r.changes;if(this._trimAutoWhitespaceLines=r.trimAutoWhitespaceLineNumbers,0!==s.length){for(let n=0,r=s.length;n=0;t--){const n=l+t,r=p+t;C.takeFromEndWhile((e=>e.lineNumber>r));const i=C.takeFromEndWhile((e=>e.lineNumber===r));e.push(new Or(n,this.getLineContent(r),i))}if(ge.lineNumbere.lineNumber===t))}e.push(new Rr(r+1,l+d,h,c))}t+=m}this._emitContentChangedEvent(new Br(e,this.getVersionId(),this._isUndoing,this._isRedoing),{changes:s,eol:this._buffer.getEOL(),isEolChange:!1,versionId:this.getVersionId(),isUndoing:this._isUndoing,isRedoing:this._isRedoing,isFlush:!1})}return null===r.reverseEdits?void 0:r.reverseEdits}undo(){return this._undoRedoService.undo(this.uri)}canUndo(){return this._undoRedoService.canUndo(this.uri)}redo(){return this._undoRedoService.redo(this.uri)}canRedo(){return this._undoRedoService.canRedo(this.uri)}handleBeforeFireDecorationsChangedEvent(e){if(null===e||0===e.size)return;const t=Array.from(e).map((e=>new Or(e,this.getLineContent(e),this._getInjectedTextInLine(e))));this._onDidChangeInjectedText.fire(new Fr(t))}changeDecorations(e,t=0){this._assertNotDisposed();try{return this._onDidChangeDecorations.beginDeferredEmit(),this._changeDecorations(t,e)}finally{this._onDidChangeDecorations.endDeferredEmit()}}_changeDecorations(e,t){const n={addDecoration:(t,n)=>this._deltaDecorationsImpl(e,[],[{range:t,options:n}])[0],changeDecoration:(e,t)=>{this._changeDecorationImpl(e,t)},changeDecorationOptions:(e,t)=>{this._changeDecorationOptionsImpl(e,ai(t))},removeDecoration:t=>{this._deltaDecorationsImpl(e,[t],[])},deltaDecorations:(t,n)=>0===t.length&&0===n.length?[]:this._deltaDecorationsImpl(e,t,n)};let r=null;try{r=t(n)}catch(i){(0,l.dz)(i)}return n.addDecoration=Gr,n.changeDecoration=Gr,n.changeDecorationOptions=Gr,n.removeDecoration=Gr,n.deltaDecorations=Gr,r}deltaDecorations(e,t,n=0){if(this._assertNotDisposed(),e||(e=[]),0===e.length&&0===t.length)return[];try{return this._deltaDecorationCallCnt++,this._deltaDecorationCallCnt>1&&(console.warn("Invoking deltaDecorations recursively could lead to leaking decorations."),(0,l.dz)(new Error("Invoking deltaDecorations recursively could lead to leaking decorations."))),this._onDidChangeDecorations.beginDeferredEmit(),this._deltaDecorationsImpl(n,e,t)}finally{this._onDidChangeDecorations.endDeferredEmit(),this._deltaDecorationCallCnt--}}_getTrackedRange(e){return this.getDecorationRange(e)}_setTrackedRange(e,t,n){const r=e?this._decorations[e]:null;if(!r)return t?this._deltaDecorationsImpl(0,[],[{range:t,options:oi[n]}],!0)[0]:null;if(!t)return this._decorationsTree.delete(r),delete this._decorations[r.id],null;const i=this._validateRangeRelaxedNoAllocations(t),s=this._buffer.getOffsetAt(i.startLineNumber,i.startColumn),o=this._buffer.getOffsetAt(i.endLineNumber,i.endColumn);return this._decorationsTree.delete(r),r.reset(this.getVersionId(),s,o,i),r.setOptions(oi[n]),this._decorationsTree.insert(r),r.id}removeAllDecorationsWithOwnerId(e){if(this._isDisposed)return;const t=this._decorationsTree.collectNodesFromOwner(e);for(let n=0,r=t.length;nthis.getLineCount()?[]:this.getLinesDecorations(e,e,t,n)}getLinesDecorations(e,t,n=0,r=!1,i=!1){const s=this.getLineCount(),a=Math.min(s,Math.max(1,e)),l=Math.min(s,Math.max(1,t)),c=this.getLineMaxColumn(l),h=new m.Q(a,1,l,c),u=this._getDecorationsInRange(h,n,r,i);return(0,o.E4)(u,this._decorationProvider.getDecorationsInRange(h,n,r)),u}getDecorationsInRange(e,t=0,n=!1,r=!1,i=!1){const s=this.validateRange(e),a=this._getDecorationsInRange(s,t,n,i);return(0,o.E4)(a,this._decorationProvider.getDecorationsInRange(s,t,n,r)),a}getOverviewRulerDecorations(e=0,t=!1){return this._decorationsTree.getAll(this,e,t,!0,!1)}getInjectedTextDecorations(e=0){return this._decorationsTree.getAllInjectedText(this,e)}_getInjectedTextInLine(e){const t=this._buffer.getOffsetAt(e,1),n=t+this._buffer.getLineLength(e),r=this._decorationsTree.getInjectedTextInInterval(this,t,n,0);return Ir.fromDecorations(r).filter((t=>t.lineNumber===e))}getAllDecorations(e=0,t=!1){let n=this._decorationsTree.getAll(this,e,t,!1,!1);return n=n.concat(this._decorationProvider.getAllDecorations(e,t)),n}getAllMarginDecorations(e=0){return this._decorationsTree.getAll(this,e,!1,!1,!0)}_getDecorationsInRange(e,t,n,r){const i=this._buffer.getOffsetAt(e.startLineNumber,e.startColumn),s=this._buffer.getOffsetAt(e.endLineNumber,e.endColumn);return this._decorationsTree.getAllInInterval(this,i,s,t,n,r)}getRangeAt(e,t){return this._buffer.getRangeAt(e,t-e)}_changeDecorationImpl(e,t){const n=this._decorations[e];if(!n)return;if(n.options.after){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.endLineNumber)}if(n.options.before){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.startLineNumber)}const r=this._validateRangeRelaxedNoAllocations(t),i=this._buffer.getOffsetAt(r.startLineNumber,r.startColumn),s=this._buffer.getOffsetAt(r.endLineNumber,r.endColumn);this._decorationsTree.delete(n),n.reset(this.getVersionId(),i,s,r),this._decorationsTree.insert(n),this._onDidChangeDecorations.checkAffectedAndFire(n.options),n.options.after&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(r.endLineNumber),n.options.before&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(r.startLineNumber)}_changeDecorationOptionsImpl(e,t){const n=this._decorations[e];if(!n)return;const r=!(!n.options.overviewRuler||!n.options.overviewRuler.color),i=!(!t.overviewRuler||!t.overviewRuler.color);if(this._onDidChangeDecorations.checkAffectedAndFire(n.options),this._onDidChangeDecorations.checkAffectedAndFire(t),n.options.after||t.after){const e=this._decorationsTree.getNodeRange(this,n);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.endLineNumber)}if(n.options.before||t.before){const e=this._decorationsTree.getNodeRange(this,n);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.startLineNumber)}const s=r!==i,o=function(e){return!!e.after||!!e.before}(t)!==Xr(n);s||o?(this._decorationsTree.delete(n),n.setOptions(t),this._decorationsTree.insert(n)):n.setOptions(t)}_deltaDecorationsImpl(e,t,n,r=!1){const i=this.getVersionId(),s=t.length;let o=0;const a=n.length;let l=0;this._onDidChangeDecorations.beginDeferredEmit();try{const c=new Array(a);for(;othis._setLanguage(e.languageId,t))),this._setLanguage(e.languageId,t))}_setLanguage(e,t){this.tokenization.setLanguageId(e,t),this._languageService.requestRichLanguageFeatures(e)}getLanguageIdAtPosition(e,t){return this.tokenization.getLanguageIdAtPosition(e,t)}getWordAtPosition(e){return this._tokenizationTextModelPart.getWordAtPosition(e)}getWordUntilPosition(e){return this._tokenizationTextModelPart.getWordUntilPosition(e)}normalizePosition(e,t){return e}getLineIndentColumn(e){return function(e){let t=0;for(const n of e){if(" "!==n&&"\t"!==n)break;t++}return t}(this.getLineContent(e))+1}};function Jr(e){return!(!e.options.overviewRuler||!e.options.overviewRuler.color)}function Xr(e){return!!e.options.after||!!e.options.before}Qr=qr=Wr([Ur(4,Vr),Ur(5,k.L),Ur(6,se),Ur(7,H._Y)],Qr);class Yr{constructor(){this._decorationsTree0=new un,this._decorationsTree1=new un,this._injectedTextDecorationsTree=new un}ensureAllNodesHaveRanges(e){this.getAll(e,0,!1,!1,!1)}_ensureNodesHaveRanges(e,t){for(const n of t)null===n.range&&(n.range=e.getRangeAt(n.cachedAbsoluteStart,n.cachedAbsoluteEnd));return t}getAllInInterval(e,t,n,r,i,s){const o=e.getVersionId(),a=this._intervalSearch(t,n,r,i,o,s);return this._ensureNodesHaveRanges(e,a)}_intervalSearch(e,t,n,r,i,s){const o=this._decorationsTree0.intervalSearch(e,t,n,r,i,s),a=this._decorationsTree1.intervalSearch(e,t,n,r,i,s),l=this._injectedTextDecorationsTree.intervalSearch(e,t,n,r,i,s);return o.concat(a).concat(l)}getInjectedTextInInterval(e,t,n,r){const i=e.getVersionId(),s=this._injectedTextDecorationsTree.intervalSearch(t,n,r,!1,i,!1);return this._ensureNodesHaveRanges(e,s).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAllInjectedText(e,t){const n=e.getVersionId(),r=this._injectedTextDecorationsTree.search(t,!1,n,!1);return this._ensureNodesHaveRanges(e,r).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAll(e,t,n,r,i){const s=e.getVersionId(),o=this._search(t,n,r,s,i);return this._ensureNodesHaveRanges(e,o)}_search(e,t,n,r,i){if(n)return this._decorationsTree1.search(e,t,r,i);{const n=this._decorationsTree0.search(e,t,r,i),s=this._decorationsTree1.search(e,t,r,i),o=this._injectedTextDecorationsTree.search(e,t,r,i);return n.concat(s).concat(o)}}collectNodesFromOwner(e){const t=this._decorationsTree0.collectNodesFromOwner(e),n=this._decorationsTree1.collectNodesFromOwner(e),r=this._injectedTextDecorationsTree.collectNodesFromOwner(e);return t.concat(n).concat(r)}collectNodesPostOrder(){const e=this._decorationsTree0.collectNodesPostOrder(),t=this._decorationsTree1.collectNodesPostOrder(),n=this._injectedTextDecorationsTree.collectNodesPostOrder();return e.concat(t).concat(n)}insert(e){Xr(e)?this._injectedTextDecorationsTree.insert(e):Jr(e)?this._decorationsTree1.insert(e):this._decorationsTree0.insert(e)}delete(e){Xr(e)?this._injectedTextDecorationsTree.delete(e):Jr(e)?this._decorationsTree1.delete(e):this._decorationsTree0.delete(e)}getNodeRange(e,t){const n=e.getVersionId();return t.cachedVersionId!==n&&this._resolveNode(t,n),null===t.range&&(t.range=e.getRangeAt(t.cachedAbsoluteStart,t.cachedAbsoluteEnd)),t.range}_resolveNode(e,t){Xr(e)?this._injectedTextDecorationsTree.resolveNode(e,t):Jr(e)?this._decorationsTree1.resolveNode(e,t):this._decorationsTree0.resolveNode(e,t)}acceptReplace(e,t,n,r){this._decorationsTree0.acceptReplace(e,t,n,r),this._decorationsTree1.acceptReplace(e,t,n,r),this._injectedTextDecorationsTree.acceptReplace(e,t,n,r)}}function Zr(e){return e.replace(/[^a-z0-9\-_]/gi," ")}class ei{constructor(e){this.color=e.color||"",this.darkColor=e.darkColor||""}}class ti extends ei{constructor(e){super(e),this._resolvedColor=null,this.position="number"===typeof e.position?e.position:me.A5.Center}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=null}_resolveColor(e,t){if("string"===typeof e)return e;const n=e?t.getColor(e.id):null;return n?n.toString():""}}class ni{constructor(e){this.position=e?.position??me.ZS.Center,this.persistLane=e?.persistLane}}class ri extends ei{constructor(e){super(e),this.position=e.position,this.sectionHeaderStyle=e.sectionHeaderStyle??null,this.sectionHeaderText=e.sectionHeaderText??null}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=void 0}_resolveColor(e,t){return"string"===typeof e?a.Q1.fromHex(e):t.getColor(e.id)}}class ii{static from(e){return e instanceof ii?e:new ii(e)}constructor(e){this.content=e.content||"",this.inlineClassName=e.inlineClassName||null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.attachedData=e.attachedData||null,this.cursorStops=e.cursorStops||null}}class si{static register(e){return new si(e)}static createDynamic(e){return new si(e)}constructor(e){this.description=e.description,this.blockClassName=e.blockClassName?Zr(e.blockClassName):null,this.blockDoesNotCollapse=e.blockDoesNotCollapse??null,this.blockIsAfterEnd=e.blockIsAfterEnd??null,this.blockPadding=e.blockPadding??null,this.stickiness=e.stickiness||0,this.zIndex=e.zIndex||0,this.className=e.className?Zr(e.className):null,this.shouldFillLineOnLineBreak=e.shouldFillLineOnLineBreak??null,this.hoverMessage=e.hoverMessage||null,this.glyphMarginHoverMessage=e.glyphMarginHoverMessage||null,this.lineNumberHoverMessage=e.lineNumberHoverMessage||null,this.isWholeLine=e.isWholeLine||!1,this.showIfCollapsed=e.showIfCollapsed||!1,this.collapseOnReplaceEdit=e.collapseOnReplaceEdit||!1,this.overviewRuler=e.overviewRuler?new ti(e.overviewRuler):null,this.minimap=e.minimap?new ri(e.minimap):null,this.glyphMargin=e.glyphMarginClassName?new ni(e.glyphMargin):null,this.glyphMarginClassName=e.glyphMarginClassName?Zr(e.glyphMarginClassName):null,this.linesDecorationsClassName=e.linesDecorationsClassName?Zr(e.linesDecorationsClassName):null,this.lineNumberClassName=e.lineNumberClassName?Zr(e.lineNumberClassName):null,this.linesDecorationsTooltip=e.linesDecorationsTooltip?c.jy(e.linesDecorationsTooltip):null,this.firstLineDecorationClassName=e.firstLineDecorationClassName?Zr(e.firstLineDecorationClassName):null,this.marginClassName=e.marginClassName?Zr(e.marginClassName):null,this.inlineClassName=e.inlineClassName?Zr(e.inlineClassName):null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.beforeContentClassName=e.beforeContentClassName?Zr(e.beforeContentClassName):null,this.afterContentClassName=e.afterContentClassName?Zr(e.afterContentClassName):null,this.after=e.after?ii.from(e.after):null,this.before=e.before?ii.from(e.before):null,this.hideInCommentTokens=e.hideInCommentTokens??!1,this.hideInStringTokens=e.hideInStringTokens??!1}}si.EMPTY=si.register({description:"empty"});const oi=[si.register({description:"tracked-range-always-grows-when-typing-at-edges",stickiness:0}),si.register({description:"tracked-range-never-grows-when-typing-at-edges",stickiness:1}),si.register({description:"tracked-range-grows-only-when-typing-before",stickiness:2}),si.register({description:"tracked-range-grows-only-when-typing-after",stickiness:3})];function ai(e){return e instanceof si?e:si.createDynamic(e)}class li extends i.jG{constructor(e){super(),this.handleBeforeFire=e,this._actual=this._register(new r.vl),this.event=this._actual.event,this._affectedInjectedTextLines=null,this._deferredCnt=0,this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._affectsLineNumber=!1}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(){this._deferredCnt--,0===this._deferredCnt&&(this._shouldFireDeferred&&this.doFire(),this._affectedInjectedTextLines?.clear(),this._affectedInjectedTextLines=null)}recordLineAffectedByInjectedText(e){this._affectedInjectedTextLines||(this._affectedInjectedTextLines=new Set),this._affectedInjectedTextLines.add(e)}checkAffectedAndFire(e){this._affectsMinimap||=!!e.minimap?.position,this._affectsOverviewRuler||=!!e.overviewRuler?.color,this._affectsGlyphMargin||=!!e.glyphMarginClassName,this._affectsLineNumber||=!!e.lineNumberClassName,this.tryFire()}fire(){this._affectsMinimap=!0,this._affectsOverviewRuler=!0,this._affectsGlyphMargin=!0,this.tryFire()}tryFire(){0===this._deferredCnt?this.doFire():this._shouldFireDeferred=!0}doFire(){this.handleBeforeFire(this._affectedInjectedTextLines);const e={affectsMinimap:this._affectsMinimap,affectsOverviewRuler:this._affectsOverviewRuler,affectsGlyphMargin:this._affectsGlyphMargin,affectsLineNumber:this._affectsLineNumber};this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._actual.fire(e)}}class ci extends i.jG{constructor(){super(),this._fastEmitter=this._register(new r.vl),this.fastEvent=this._fastEmitter.event,this._slowEmitter=this._register(new r.vl),this.slowEvent=this._slowEmitter.event,this._deferredCnt=0,this._deferredEvent=null}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(e=null){if(this._deferredCnt--,0===this._deferredCnt&&null!==this._deferredEvent){this._deferredEvent.rawContentChangedEvent.resultingSelection=e;const t=this._deferredEvent;this._deferredEvent=null,this._fastEmitter.fire(t),this._slowEmitter.fire(t)}}fire(e){this._deferredCnt>0?this._deferredEvent?this._deferredEvent=this._deferredEvent.merge(e):this._deferredEvent=e:(this._fastEmitter.fire(e),this._slowEmitter.fire(e))}}var hi,ui=n(360),di=n(5600),gi=n(6456),fi=n(146),mi=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},pi=function(e,t){return function(n,r){t(n,r,e)}};function bi(e){return e.toString()}class _i{constructor(e,t,n){this.model=e,this._modelEventListeners=new i.Cm,this.model=e,this._modelEventListeners.add(e.onWillDispose((()=>t(e)))),this._modelEventListeners.add(e.onDidChangeLanguage((t=>n(e,t))))}dispose(){this._modelEventListeners.dispose()}}const ki=s.j9||s.zx?1:2;class vi{constructor(e,t,n,r,i,s,o,a){this.uri=e,this.initialUndoRedoSnapshot=t,this.time=n,this.sharesUndoRedoStack=r,this.heapSize=i,this.sha1=s,this.versionId=o,this.alternativeVersionId=a}}let Ci=class extends i.jG{static{hi=this}static{this.MAX_MEMORY_FOR_CLOSED_FILES_UNDO_STACK=20971520}constructor(e,t,n,i){super(),this._configurationService=e,this._resourcePropertiesService=t,this._undoRedoService=n,this._instantiationService=i,this._onModelAdded=this._register(new r.vl),this.onModelAdded=this._onModelAdded.event,this._onModelRemoved=this._register(new r.vl),this.onModelRemoved=this._onModelRemoved.event,this._onModelModeChanged=this._register(new r.vl),this.onModelLanguageChanged=this._onModelModeChanged.event,this._modelCreationOptionsByLanguageAndResource=Object.create(null),this._models={},this._disposedModels=new Map,this._disposedModelsHeapSize=0,this._register(this._configurationService.onDidChangeConfiguration((e=>this._updateModelOptions(e)))),this._updateModelOptions(void 0)}static _readModelOptions(e,t){let n=b.tabSize;if(e.editor&&"undefined"!==typeof e.editor.tabSize){const t=parseInt(e.editor.tabSize,10);isNaN(t)||(n=t),n<1&&(n=1)}let r="tabSize";if(e.editor&&"undefined"!==typeof e.editor.indentSize&&"tabSize"!==e.editor.indentSize){const t=parseInt(e.editor.indentSize,10);isNaN(t)||(r=Math.max(t,1))}let i=b.insertSpaces;e.editor&&"undefined"!==typeof e.editor.insertSpaces&&(i="false"!==e.editor.insertSpaces&&Boolean(e.editor.insertSpaces));let s=ki;const o=e.eol;"\r\n"===o?s=2:"\n"===o&&(s=1);let a=b.trimAutoWhitespace;e.editor&&"undefined"!==typeof e.editor.trimAutoWhitespace&&(a="false"!==e.editor.trimAutoWhitespace&&Boolean(e.editor.trimAutoWhitespace));let l=b.detectIndentation;e.editor&&"undefined"!==typeof e.editor.detectIndentation&&(l="false"!==e.editor.detectIndentation&&Boolean(e.editor.detectIndentation));let c=b.largeFileOptimizations;e.editor&&"undefined"!==typeof e.editor.largeFileOptimizations&&(c="false"!==e.editor.largeFileOptimizations&&Boolean(e.editor.largeFileOptimizations));let h=b.bracketPairColorizationOptions;return e.editor?.bracketPairColorization&&"object"===typeof e.editor.bracketPairColorization&&(h={enabled:!!e.editor.bracketPairColorization.enabled,independentColorPoolPerBracketType:!!e.editor.bracketPairColorization.independentColorPoolPerBracketType}),{isForSimpleWidget:t,tabSize:n,indentSize:r,insertSpaces:i,detectIndentation:l,defaultEOL:s,trimAutoWhitespace:a,largeFileOptimizations:c,bracketPairColorizationOptions:h}}_getEOL(e,t){if(e)return this._resourcePropertiesService.getEOL(e,t);const n=this._configurationService.getValue("files.eol",{overrideIdentifier:t});return n&&"string"===typeof n&&"auto"!==n?n:3===s.OS||2===s.OS?"\n":"\r\n"}_shouldRestoreUndoStack(){const e=this._configurationService.getValue("files.restoreUndoStack");return"boolean"!==typeof e||e}getCreationOptions(e,t,n){const r="string"===typeof e?e:e.languageId;let i=this._modelCreationOptionsByLanguageAndResource[r+t];if(!i){const e=this._configurationService.getValue("editor",{overrideIdentifier:r,resource:t}),s=this._getEOL(t,r);i=hi._readModelOptions({editor:e,eol:s},n),this._modelCreationOptionsByLanguageAndResource[r+t]=i}return i}_updateModelOptions(e){const t=this._modelCreationOptionsByLanguageAndResource;this._modelCreationOptionsByLanguageAndResource=Object.create(null);const n=Object.keys(this._models);for(let r=0,i=n.length;re){const t=[];for(this._disposedModels.forEach((e=>{e.sharesUndoRedoStack||t.push(e)})),t.sort(((e,t)=>e.time-t.time));t.length>0&&this._disposedModelsHeapSize>e;){const e=t.shift();this._removeDisposedModel(e.uri),null!==e.initialUndoRedoSnapshot&&this._undoRedoService.restoreSnapshot(e.initialUndoRedoSnapshot)}}}_createModelData(e,t,n,r){const i=this.getCreationOptions(t,n,r),s=this._instantiationService.createInstance(Qr,e,t,i,n);if(n&&this._disposedModels.has(bi(n))){const e=this._removeDisposedModel(n),t=this._undoRedoService.getElements(n),r=this._getSHA1Computer(),i=!!r.canComputeSHA1(s)&&r.computeSHA1(s)===e.sha1;if(i||e.sharesUndoRedoStack){for(const e of t.past)zt(e)&&e.matchesResource(n)&&e.setModel(s);for(const e of t.future)zt(e)&&e.matchesResource(n)&&e.setModel(s);this._undoRedoService.setElementsValidFlag(n,!0,(e=>zt(e)&&e.matchesResource(n))),i&&(s._overwriteVersionId(e.versionId),s._overwriteAlternativeVersionId(e.alternativeVersionId),s._overwriteInitialUndoRedoSnapshot(e.initialUndoRedoSnapshot))}else null!==e.initialUndoRedoSnapshot&&this._undoRedoService.restoreSnapshot(e.initialUndoRedoSnapshot)}const o=bi(s.uri);if(this._models[o])throw new Error("ModelService: Cannot add model because it already exists!");const a=new _i(s,(e=>this._onWillDispose(e)),((e,t)=>this._onDidChangeLanguage(e,t)));return this._models[o]=a,a}createModel(e,t,n,r=!1){let i;return i=t?this._createModelData(e,t,n,r):this._createModelData(e,Q.vH,n,r),this._onModelAdded.fire(i.model),i.model}getModels(){const e=[],t=Object.keys(this._models);for(let n=0,r=t.length;n0||t.future.length>0){for(const n of t.past)zt(n)&&n.matchesResource(e.uri)&&(i=!0,s+=n.heapSize(e.uri),n.setModel(e.uri));for(const n of t.future)zt(n)&&n.matchesResource(e.uri)&&(i=!0,s+=n.heapSize(e.uri),n.setModel(e.uri))}}const o=hi.MAX_MEMORY_FOR_CLOSED_FILES_UNDO_STACK,a=this._getSHA1Computer();if(i)if(r||!(s>o)&&a.canComputeSHA1(e))this._ensureDisposedModelsHeapSize(o-s),this._undoRedoService.setElementsValidFlag(e.uri,!1,(t=>zt(t)&&t.matchesResource(e.uri))),this._insertDisposedModel(new vi(e.uri,n.model.getInitialUndoRedoSnapshot(),Date.now(),r,s,a.computeSHA1(e),e.getVersionId(),e.getAlternativeVersionId()));else{const e=n.model.getInitialUndoRedoSnapshot();null!==e&&this._undoRedoService.restoreSnapshot(e)}else if(!r){const e=n.model.getInitialUndoRedoSnapshot();null!==e&&this._undoRedoService.restoreSnapshot(e)}delete this._models[t],n.dispose(),delete this._modelCreationOptionsByLanguageAndResource[e.getLanguageId()+e.uri],this._onModelRemoved.fire(e)}_onDidChangeLanguage(e,t){const n=t.oldLanguage,r=e.getLanguageId(),i=this.getCreationOptions(n,e.uri,e.isForSimpleWidget),s=this.getCreationOptions(r,e.uri,e.isForSimpleWidget);hi._setModelOptionsForModel(e,s,i),this._onModelModeChanged.fire({model:e,oldLanguageId:n})}_getSHA1Computer(){return new yi}};Ci=hi=mi([pi(0,K.pG),pi(1,ui.ITextResourcePropertiesService),pi(2,Vr),pi(3,H._Y)],Ci);class yi{static{this.MAX_MODEL_SIZE=10485760}canComputeSHA1(e){return e.getValueLength()<=yi.MAX_MODEL_SIZE}computeSHA1(e){const t=new di.v7,n=e.createSnapshot();let r;for(;r=n.read();)t.update(r);return t.digest()}}},8938:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITextModelService:()=>r});const r=(0,n(3591).u1)("textModelService")},8232:(e,t,n)=>{"use strict";n.r(t),n.d(t,{encodeSemanticTokensDto:()=>s});var r=n(1674),i=n(8067);function s(e){const t=new Uint32Array(function(e){let t=0;if(t+=2,"full"===e.type)t+=1+e.data.length;else{t+=1,t+=3*e.deltas.length;for(const n of e.deltas)n.data&&(t+=n.data.length)}return t}(e));let n=0;if(t[n++]=e.id,"full"===e.type)t[n++]=1,t[n++]=e.data.length,t.set(e.data,n),n+=e.data.length;else{t[n++]=2,t[n++]=e.deltas.length;for(const r of e.deltas)t[n++]=r.start,t[n++]=r.deleteCount,r.data?(t[n++]=r.data.length,t.set(r.data,n),n+=r.data.length):t[n++]=0}return function(e){const t=new Uint8Array(e.buffer,e.byteOffset,4*e.length);return i.cm()||function(e){for(let t=0,n=e.length;t{"use strict";n.r(t),n.d(t,{SemanticTokensProviderStyling:()=>m,toMultilineTokens2:()=>p});n(5982);var r=n(5724),i=n(3511),s=n(3069),o=n(6677),a=n(4454);class l{static create(e,t){return new l(e,new c(t))}get startLineNumber(){return this._startLineNumber}get endLineNumber(){return this._endLineNumber}constructor(e,t){this._startLineNumber=e,this._tokens=t,this._endLineNumber=this._startLineNumber+this._tokens.getMaxDeltaLine()}toString(){return this._tokens.toString(this._startLineNumber)}_updateEndLineNumber(){this._endLineNumber=this._startLineNumber+this._tokens.getMaxDeltaLine()}isEmpty(){return this._tokens.isEmpty()}getLineTokens(e){return this._startLineNumber<=e&&e<=this._endLineNumber?this._tokens.getLineTokens(e-this._startLineNumber):null}getRange(){const e=this._tokens.getRange();return e?new o.Q(this._startLineNumber+e.startLineNumber,e.startColumn,this._startLineNumber+e.endLineNumber,e.endColumn):e}removeTokens(e){const t=e.startLineNumber-this._startLineNumber,n=e.endLineNumber-this._startLineNumber;this._startLineNumber+=this._tokens.removeTokens(t,e.startColumn-1,n,e.endColumn-1),this._updateEndLineNumber()}split(e){const t=e.startLineNumber-this._startLineNumber,n=e.endLineNumber-this._startLineNumber,[r,i,s]=this._tokens.split(t,e.startColumn-1,n,e.endColumn-1);return[new l(this._startLineNumber,r),new l(this._startLineNumber+s,i)]}applyEdit(e,t){const[n,r,i]=(0,a.W)(t);this.acceptEdit(e,n,r,i,t.length>0?t.charCodeAt(0):0)}acceptEdit(e,t,n,r,i){this._acceptDeleteRange(e),this._acceptInsertText(new s.y(e.startLineNumber,e.startColumn),t,n,r,i),this._updateEndLineNumber()}_acceptDeleteRange(e){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return;const t=e.startLineNumber-this._startLineNumber,n=e.endLineNumber-this._startLineNumber;if(n<0){const e=n-t;return void(this._startLineNumber-=e)}const r=this._tokens.getMaxDeltaLine();if(!(t>=r+1)){if(t<0&&n>=r+1)return this._startLineNumber=0,void this._tokens.clear();if(t<0){const r=-t;this._startLineNumber-=r,this._tokens.acceptDeleteRange(e.startColumn-1,0,0,n,e.endColumn-1)}else this._tokens.acceptDeleteRange(0,t,e.startColumn-1,n,e.endColumn-1)}}_acceptInsertText(e,t,n,r,i){if(0===t&&0===n)return;const s=e.lineNumber-this._startLineNumber;if(s<0)return void(this._startLineNumber+=t);s>=this._tokens.getMaxDeltaLine()+1||this._tokens.acceptInsertText(s,e.column-1,t,n,r,i)}}class c{constructor(e){this._tokens=e,this._tokenCount=e.length/4}toString(e){const t=[];for(let n=0;ne)){let i=r;for(;i>t&&this._getDeltaLine(i-1)===e;)i--;let s=r;for(;se||h===e&&d>=t)&&(he||o===e&&g>=t){if(oi?f-=i-n:f=n;else if(d===t&&g===n){if(!(d===r&&f>i)){c=!0;continue}f-=i-n}else if(di)){c=!0;continue}d=t,g=n,f=g+(f-i)}else if(d>r){if(0===a&&!c){l=o;break}d-=a}else{if(!(d===r&&g>=i))throw new Error("Not possible!");e&&0===d&&(g+=e,f+=e),d-=a,g-=i-n,f-=i-n}const p=4*l;s[p]=d,s[p+1]=g,s[p+2]=f,s[p+3]=m,l++}this._tokenCount=l}acceptInsertText(e,t,n,r,i,s){const o=0===n&&1===r&&(s>=48&&s<=57||s>=65&&s<=90||s>=97&&s<=122),a=this._tokens,l=this._tokenCount;for(let c=0;c=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},g=function(e,t){return function(n,r){t(n,r,e)}};const f=!1;let m=class{constructor(e,t,n,r){this._legend=e,this._themeService=t,this._languageService=n,this._logService=r,this._hasWarnedOverlappingTokens=!1,this._hasWarnedInvalidLengthTokens=!1,this._hasWarnedInvalidEditStart=!1,this._hashTable=new _}getMetadata(e,t,n){const r=this._languageService.languageIdCodec.encodeLanguageId(n),i=this._hashTable.get(e,t,r);let s;if(i)s=i.metadata;else{let i=this._legend.tokenTypes[e];const o=[];if(i){let e=t;for(let t=0;e>0&&t>=1;f;const r=this._themeService.getColorTheme().getTokenStyleMetadata(i,o,n);if("undefined"===typeof r)s=2147483647;else{if(s=0,"undefined"!==typeof r.italic){s|=1|(r.italic?1:0)<<11}if("undefined"!==typeof r.bold){s|=2|(r.bold?2:0)<<11}if("undefined"!==typeof r.underline){s|=4|(r.underline?4:0)<<11}if("undefined"!==typeof r.strikethrough){s|=8|(r.strikethrough?8:0)<<11}if(r.foreground){s|=16|r.foreground<<15}0===s&&(s=2147483647)}}else s=2147483647,i="not-in-legend";this._hashTable.add(e,t,r,s)}return s}warnOverlappingSemanticTokens(e,t){this._hasWarnedOverlappingTokens||(this._hasWarnedOverlappingTokens=!0,this._logService.warn(`Overlapping semantic tokens detected at lineNumber ${e}, column ${t}`))}warnInvalidLengthSemanticTokens(e,t){this._hasWarnedInvalidLengthTokens||(this._hasWarnedInvalidLengthTokens=!0,this._logService.warn(`Semantic token with invalid length detected at lineNumber ${e}, column ${t}`))}warnInvalidEditStart(e,t,n,r,i){this._hasWarnedInvalidEditStart||(this._hasWarnedInvalidEditStart=!0,this._logService.warn(`Invalid semantic tokens edit detected (previousResultId: ${e}, resultId: ${t}) at edit #${n}: The provided start offset ${r} is outside the previous data (length ${i}).`))}};function p(e,t,n){const r=e.data,i=e.data.length/5|0,s=Math.max(Math.ceil(i/1024),400),o=[];let a=0,c=1,h=0;for(;ae&&0===r[5*t];)t--;if(t-1===e){let e=u;for(;e+1l)t.warnOverlappingSemanticTokens(o,l+1);else{const e=t.getMetadata(b,_,n);2147483647!==e&&(0===f&&(f=o),d[g]=o-f,d[g+1]=l,d[g+2]=u,d[g+3]=e,g+=4,m=o,p=u)}c=o,h=l,a++}g!==d.length&&(d=d.subarray(0,g));const b=l.create(f,d);o.push(b)}return o}m=d([g(1,r.Gy),g(2,u.L),g(3,i.rr)],m);class b{constructor(e,t,n,r){this.tokenTypeIndex=e,this.tokenModifierSet=t,this.languageId=n,this.metadata=r,this.next=null}}class _{static{this._SIZES=[3,7,13,31,61,127,251,509,1021,2039,4093,8191,16381,32749,65521,131071,262139,524287,1048573,2097143]}constructor(){this._elementsCount=0,this._currentLengthIndex=0,this._currentLength=_._SIZES[this._currentLengthIndex],this._growCount=Math.round(this._currentLengthIndex+1<_._SIZES.length?2/3*this._currentLength:0),this._elements=[],_._nullOutEntries(this._elements,this._currentLength)}static _nullOutEntries(e,t){for(let n=0;n=this._growCount){const e=this._elements;this._currentLengthIndex++,this._currentLength=_._SIZES[this._currentLengthIndex],this._growCount=Math.round(this._currentLengthIndex+1<_._SIZES.length?2/3*this._currentLength:0),this._elements=[],_._nullOutEntries(this._elements,this._currentLength);for(const t of e){let e=t;for(;e;){const t=e.next;e.next=null,this._add(e),e=t}}}this._add(new b(e,t,n,r))}_add(e){const t=this._hashFunc(e.tokenTypeIndex,e.tokenModifierSet,e.languageId);e.next=this._elements[t],this._elements[t]=e}}},4243:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ISemanticTokensStylingService:()=>r});const r=(0,n(3591).u1)("semanticTokensStylingService")},7004:(e,t,n)=>{"use strict";n.r(t),n.d(t,{SemanticTokensStylingService:()=>d});var r=n(1484),i=n(154),s=n(5724),o=n(3511),a=n(5538),l=n(4243),c=n(4621),h=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},u=function(e,t){return function(n,r){t(n,r,e)}};let d=class extends r.jG{constructor(e,t,n){super(),this._themeService=e,this._logService=t,this._languageService=n,this._caches=new WeakMap,this._register(this._themeService.onDidColorThemeChange((()=>{this._caches=new WeakMap})))}getStyling(e){return this._caches.has(e)||this._caches.set(e,new a.SemanticTokensProviderStyling(e.getLegend(),this._themeService,this._languageService,this._logService)),this._caches.get(e)}};d=h([u(0,s.Gy),u(1,o.rr),u(2,i.L)],d),(0,c.v)(l.ISemanticTokensStylingService,d,1)},796:(e,t,n)=>{"use strict";n.r(t),n.d(t,{MirrorModel:()=>b,STOP_SYNC_MODEL_DELTA_TIME_MS:()=>f,WorkerTextModelSyncClient:()=>m,WorkerTextModelSyncServer:()=>p});var r=n(1940),i=n(1484),s=n(9400),o=n(3069),a=n(6677),l=n(6486),c=n(1508),h=(n(9861),n(5152));class u{constructor(e){this.values=e,this.prefixSum=new Uint32Array(e.length),this.prefixSumValidIndex=new Int32Array(1),this.prefixSumValidIndex[0]=-1}insertValues(e,t){e=(0,h.j)(e);const n=this.values,r=this.prefixSum,i=t.length;return 0!==i&&(this.values=new Uint32Array(n.length+i),this.values.set(n.subarray(0,e),0),this.values.set(n.subarray(e),e+i),this.values.set(t,e),e-1=0&&this.prefixSum.set(r.subarray(0,this.prefixSumValidIndex[0]+1)),!0)}setValue(e,t){return e=(0,h.j)(e),t=(0,h.j)(t),this.values[e]!==t&&(this.values[e]=t,e-1=n.length)return!1;const i=n.length-e;return t>=i&&(t=i),0!==t&&(this.values=new Uint32Array(n.length-t),this.values.set(n.subarray(0,e),0),this.values.set(n.subarray(e+t),e),this.prefixSum=new Uint32Array(this.values.length),e-1=0&&this.prefixSum.set(r.subarray(0,this.prefixSumValidIndex[0]+1)),!0)}getTotalSum(){return 0===this.values.length?0:this._getPrefixSum(this.values.length-1)}getPrefixSum(e){return e<0?0:(e=(0,h.j)(e),this._getPrefixSum(e))}_getPrefixSum(e){if(e<=this.prefixSumValidIndex[0])return this.prefixSum[e];let t=this.prefixSumValidIndex[0]+1;0===t&&(this.prefixSum[0]=this.values[0],t++),e>=this.values.length&&(e=this.values.length-1);for(let n=t;n<=e;n++)this.prefixSum[n]=this.prefixSum[n-1]+this.values[n];return this.prefixSumValidIndex[0]=Math.max(this.prefixSumValidIndex[0],e),this.prefixSum[e]}getIndexOf(e){e=Math.floor(e),this.getTotalSum();let t=0,n=this.values.length-1,r=0,i=0,s=0;for(;t<=n;)if(r=t+(n-t)/2|0,i=this.prefixSum[r],s=i-this.values[r],e=i))break;t=r+1}return new d(r,e-s)}}class d{constructor(e,t){this.index=e,this.remainder=t,this._prefixSumIndexOfResultBrand=void 0,this.index=e,this.remainder=t}}class g{constructor(e,t,n,r){this._uri=e,this._lines=t,this._eol=n,this._versionId=r,this._lineStarts=null,this._cachedTextValue=null}dispose(){this._lines.length=0}get version(){return this._versionId}getText(){return null===this._cachedTextValue&&(this._cachedTextValue=this._lines.join(this._eol)),this._cachedTextValue}onEvents(e){e.eol&&e.eol!==this._eol&&(this._eol=e.eol,this._lineStarts=null);const t=e.changes;for(const n of t)this._acceptDeleteRange(n.range),this._acceptInsertText(new o.y(n.range.startLineNumber,n.range.startColumn),n.text);this._versionId=e.versionId,this._cachedTextValue=null}_ensureLineStarts(){if(!this._lineStarts){const e=this._eol.length,t=this._lines.length,n=new Uint32Array(t);for(let r=0;rthis._checkStopModelSync()),Math.round(f/2)),this._register(e)}}dispose(){for(const e in this._syncedModels)(0,i.AS)(this._syncedModels[e]);this._syncedModels=Object.create(null),this._syncedModelsLastUsedTime=Object.create(null),super.dispose()}ensureSyncedResources(e,t=!1){for(const n of e){const e=n.toString();this._syncedModels[e]||this._beginModelSync(n,t),this._syncedModels[e]&&(this._syncedModelsLastUsedTime[e]=(new Date).getTime())}}_checkStopModelSync(){const e=(new Date).getTime(),t=[];for(const n in this._syncedModelsLastUsedTime){e-this._syncedModelsLastUsedTime[n]>f&&t.push(n)}for(const n of t)this._stopModelSync(n)}_beginModelSync(e,t){const n=this._modelService.getModel(e);if(!n)return;if(!t&&n.isTooLargeForSyncing())return;const r=e.toString();this._proxy.$acceptNewModel({url:n.uri.toString(),lines:n.getLinesContent(),EOL:n.getEOL(),versionId:n.getVersionId()});const s=new i.Cm;s.add(n.onDidChangeContent((e=>{this._proxy.$acceptModelChanged(r.toString(),e)}))),s.add(n.onWillDispose((()=>{this._stopModelSync(r)}))),s.add((0,i.s)((()=>{this._proxy.$acceptRemovedModel(r)}))),this._syncedModels[r]=s}_stopModelSync(e){const t=this._syncedModels[e];delete this._syncedModels[e],delete this._syncedModelsLastUsedTime[e],(0,i.AS)(t)}}class p{constructor(){this._models=Object.create(null)}getModel(e){return this._models[e]}getModels(){const e=[];return Object.keys(this._models).forEach((t=>e.push(this._models[t]))),e}$acceptNewModel(e){this._models[e.url]=new b(s.r.parse(e.url),e.lines,e.EOL,e.versionId)}$acceptModelChanged(e,t){if(!this._models[e])return;this._models[e].onEvents(t)}$acceptRemovedModel(e){this._models[e]&&delete this._models[e]}}class b extends g{get uri(){return this._uri}get eol(){return this._eol}getValue(){return this.getText()}findMatches(e){const t=[];for(let n=0;nthis._lines.length)t=this._lines.length,n=this._lines[t-1].length+1,r=!0;else{const e=this._lines[t-1].length+1;n<1?(n=1,r=!0):n>e&&(n=e,r=!0)}return r?{lineNumber:t,column:n}:e}}},8868:(e,t,n)=>{"use strict";n.r(t)},360:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITextResourceConfigurationService:()=>i,ITextResourcePropertiesService:()=>s});var r=n(3591);const i=(0,r.u1)("textResourceConfigurationService"),s=(0,r.u1)("textResourcePropertiesService")},4432:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITreeSitterParserService:()=>r});const r=(0,n(3591).u1)("treeSitterParserService")},6723:(e,t,n)=>{"use strict";n.r(t),n.d(t,{DraggedTreeItemsIdentifier:()=>i,TreeViewsDnDService:()=>r});class r{constructor(){this._dragOperations=new Map}removeDragOperationTransfer(e){if(e&&this._dragOperations.has(e)){const t=this._dragOperations.get(e);return this._dragOperations.delete(e),t}}}class i{constructor(e){this.identifier=e}}},9100:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITreeViewsDnDService:()=>o});var r=n(4621),i=n(3591),s=n(6723);const o=(0,i.u1)("treeViewsDndService");(0,r.v)(o,s.TreeViewsDnDService,1)},4855:(e,t,n)=>{"use strict";n.r(t),n.d(t,{UnicodeTextModelHighlighter:()=>l});var r=n(6677),i=n(7729),s=n(1508),o=n(6782),a=n(6486);class l{static computeUnicodeHighlights(e,t,n){const l=n?n.startLineNumber:1,h=n?n.endLineNumber:e.getLineCount(),u=new c(t),d=u.getCandidateCodePoints();let g;var f;g="allNonBasicAscii"===d?new RegExp("[^\\t\\n\\r\\x20-\\x7E]","g"):new RegExp(""+(f=Array.from(d),`[${s.bm(f.map((e=>String.fromCodePoint(e))).join(""))}]`),"g");const m=new i.W5(null,g),p=[];let b,_=!1,k=0,v=0,C=0;e:for(let i=l,c=h;i<=c;i++){const t=e.getLineContent(i),n=t.length;m.reset(0);do{if(b=m.next(t),b){let e=b.index,l=b.index+b[0].length;if(e>0){const n=t.charCodeAt(e-1);s.pc(n)&&e--}if(l+1=t){_=!0;break e}p.push(new r.Q(i,e+1,i,l+1))}}}while(b)}return{ranges:p,hasMore:_,ambiguousCharacterCount:k,invisibleCharacterCount:v,nonBasicAsciiCharacterCount:C}}static computeUnicodeHighlightReason(e,t){const n=new c(t);switch(n.shouldHighlightNonBasicASCII(e,null)){case 0:return null;case 2:return{kind:1};case 3:{const r=e.codePointAt(0),i=n.ambiguousCharacters.getPrimaryConfusable(r),o=s.tl.getLocales().filter((e=>!s.tl.getInstance(new Set([...t.allowedLocales,e])).isAmbiguous(r)));return{kind:0,confusableWith:String.fromCodePoint(i),notAmbiguousInLocales:o}}case 1:return{kind:2}}}}class c{constructor(e){this.options=e,this.allowedCodePoints=new Set(e.allowedCodePoints),this.ambiguousCharacters=s.tl.getInstance(new Set(e.allowedLocales))}getCandidateCodePoints(){if(this.options.nonBasicASCII)return"allNonBasicAscii";const e=new Set;if(this.options.invisibleCharacters)for(const t of s.y_.codePoints)h(String.fromCodePoint(t))||e.add(t);if(this.options.ambiguousCharacters)for(const t of this.ambiguousCharacters.getConfusableCodePoints())e.add(t);for(const t of this.allowedCodePoints)e.delete(t);return e}shouldHighlightNonBasicASCII(e,t){const n=e.codePointAt(0);if(this.allowedCodePoints.has(n))return 0;if(this.options.nonBasicASCII)return 1;let r=!1,i=!1;if(t)for(const o of t){const e=o.codePointAt(0),t=s.aC(o);r=r||t,t||this.ambiguousCharacters.isAmbiguous(e)||s.y_.isInvisibleCharacter(e)||(i=!0)}return!r&&i?0:this.options.invisibleCharacters&&!h(e)&&s.y_.isInvisibleCharacter(n)?2:this.options.ambiguousCharacters&&this.ambiguousCharacters.isAmbiguous(n)?3:0}}function h(e){return" "===e||"\n"===e||"\t"===e}},8209:(e,t,n)=>{"use strict";function r(){return globalThis._VSCODE_NLS_LANGUAGE}n.d(t,{i8:()=>r,kg:()=>o});const i="pseudo"===r()||"undefined"!==typeof document&&document.location&&document.location.hash.indexOf("pseudo=true")>=0;function s(e,t){let n;return n=0===t.length?e:e.replace(/\{(\d+)\}/g,((e,n)=>{const r=n[0],i=t[r];let s=e;return"string"===typeof i?s=i:"number"!==typeof i&&"boolean"!==typeof i&&void 0!==i&&null!==i||(s=String(i)),s})),i&&(n="\uff3b"+n.replace(/[aouei]/g,"$&$&")+"\uff3d"),n}function o(e,t,...n){return s("number"===typeof e?a(e,t):t,n)}function a(e,t){const n=globalThis._VSCODE_NLS_MESSAGES?.[e];if("string"!==typeof n){if("string"===typeof t)return t;throw new Error(`!!! NLS MISSING: ${e} !!!`)}return n}},4001:(e,t,n)=>{"use strict";n.d(t,{Mo:()=>i,pG:()=>r});const r=(0,n(3591).u1)("configurationService");function i(e){return e.replace(/[\[\]]/g,"")}},1646:(e,t,n)=>{"use strict";n.d(t,{Fd:()=>h});var r=n(9861),i=n(1234),s=n(631),o=n(8209),a=n(4001),l=n(8748),c=n(6359);const h={Configuration:"base.contributions.configuration"},u={properties:{},patternProperties:{}},d={properties:{},patternProperties:{}},g={properties:{},patternProperties:{}},f={properties:{},patternProperties:{}},m={properties:{},patternProperties:{}},p={properties:{},patternProperties:{}},b="vscode://schemas/settings/resourceLanguage",_=c.O.as(l.F.JSONContribution);const k="\\[([^\\]]+)\\]",v=new RegExp(k,"g"),C=`^(${k})+$`,y=new RegExp(C);function L(e){const t=[];if(y.test(e)){let n=v.exec(e);for(;n?.length;){const r=n[1].trim();r&&t.push(r),n=v.exec(e)}}return(0,r.dM)(t)}const w=new class{constructor(){this.registeredConfigurationDefaults=[],this.overrideIdentifiers=new Set,this._onDidSchemaChange=new i.vl,this._onDidUpdateConfiguration=new i.vl,this.configurationDefaultsOverrides=new Map,this.defaultLanguageConfigurationOverridesNode={id:"defaultOverrides",title:o.kg("defaultLanguageConfigurationOverrides.title","Default Language Configuration Overrides"),properties:{}},this.configurationContributors=[this.defaultLanguageConfigurationOverridesNode],this.resourceLanguageSettingsSchema={properties:{},patternProperties:{},additionalProperties:!0,allowTrailingCommas:!0,allowComments:!0},this.configurationProperties={},this.policyConfigurations=new Map,this.excludedConfigurationProperties={},_.registerSchema(b,this.resourceLanguageSettingsSchema),this.registerOverridePropertyPatternKey()}registerConfiguration(e,t=!0){this.registerConfigurations([e],t)}registerConfigurations(e,t=!0){const n=new Set;this.doRegisterConfigurations(e,t,n),_.registerSchema(b,this.resourceLanguageSettingsSchema),this._onDidSchemaChange.fire(),this._onDidUpdateConfiguration.fire({properties:n})}registerDefaultConfigurations(e){const t=new Set;this.doRegisterDefaultConfigurations(e,t),this._onDidSchemaChange.fire(),this._onDidUpdateConfiguration.fire({properties:t,defaultsOverrides:!0})}doRegisterDefaultConfigurations(e,t){this.registeredConfigurationDefaults.push(...e);const n=[];for(const{overrides:r,source:i}of e)for(const e in r){t.add(e);const s=this.configurationDefaultsOverrides.get(e)??this.configurationDefaultsOverrides.set(e,{configurationDefaultOverrides:[]}).get(e),o=r[e];if(s.configurationDefaultOverrides.push({value:o,source:i}),y.test(e)){const t=this.mergeDefaultConfigurationsForOverrideIdentifier(e,o,i,s.configurationDefaultOverrideValue);if(!t)continue;s.configurationDefaultOverrideValue=t,this.updateDefaultOverrideProperty(e,t,i),n.push(...L(e))}else{const t=this.mergeDefaultConfigurationsForConfigurationProperty(e,o,i,s.configurationDefaultOverrideValue);if(!t)continue;s.configurationDefaultOverrideValue=t;const n=this.configurationProperties[e];n&&(this.updatePropertyDefaultValue(e,n),this.updateSchema(e,n))}}this.doRegisterOverrideIdentifiers(n)}updateDefaultOverrideProperty(e,t,n){const r={type:"object",default:t.value,description:o.kg("defaultLanguageConfiguration.description","Configure settings to be overridden for the {0} language.",(0,a.Mo)(e)),$ref:b,defaultDefaultValue:t.value,source:n,defaultValueSource:n};this.configurationProperties[e]=r,this.defaultLanguageConfigurationOverridesNode.properties[e]=r}mergeDefaultConfigurationsForOverrideIdentifier(e,t,n,r){const i=r?.value||{},o=r?.source??new Map;if(o instanceof Map){for(const e of Object.keys(t)){const r=t[e];if(s.Gv(r)&&(s.b0(i[e])||s.Gv(i[e]))){if(i[e]={...i[e]??{},...r},n)for(const t in r)o.set(`${e}.${t}`,n)}else i[e]=r,n?o.set(e,n):o.delete(e)}return{value:i,source:o}}console.error("objectConfigurationSources is not a Map")}mergeDefaultConfigurationsForConfigurationProperty(e,t,n,r){const i=this.configurationProperties[e],o=r?.value??i?.defaultDefaultValue;let a=n;if(s.Gv(t)&&(void 0!==i&&"object"===i.type||void 0===i&&(s.b0(o)||s.Gv(o)))){if(a=r?.source??new Map,!(a instanceof Map))return void console.error("defaultValueSource is not a Map");for(const r in t)n&&a.set(`${e}.${r}`,n);t={...s.Gv(o)?o:{},...t}}return{value:t,source:a}}registerOverrideIdentifiers(e){this.doRegisterOverrideIdentifiers(e),this._onDidSchemaChange.fire()}doRegisterOverrideIdentifiers(e){for(const t of e)this.overrideIdentifiers.add(t);this.updateOverridePropertyPatternKey()}doRegisterConfigurations(e,t,n){e.forEach((e=>{this.validateAndRegisterProperties(e,t,e.extensionInfo,e.restrictedProperties,void 0,n),this.configurationContributors.push(e),this.registerJSONConfiguration(e)}))}validateAndRegisterProperties(e,t=!0,n,r,i=3,o){i=s.z(e.scope)?i:e.scope;const a=e.properties;if(a)for(const c in a){const e=a[c];t&&S(c,e)?delete a[c]:(e.source=n,e.defaultDefaultValue=a[c].default,this.updatePropertyDefaultValue(c,e),y.test(c)?e.scope=void 0:(e.scope=s.z(e.scope)?i:e.scope,e.restricted=s.z(e.restricted)?!!r?.includes(c):e.restricted),!a[c].hasOwnProperty("included")||a[c].included?(this.configurationProperties[c]=a[c],a[c].policy?.name&&this.policyConfigurations.set(a[c].policy.name,c),!a[c].deprecationMessage&&a[c].markdownDeprecationMessage&&(a[c].deprecationMessage=a[c].markdownDeprecationMessage),o.add(c)):(this.excludedConfigurationProperties[c]=a[c],delete a[c]))}const l=e.allOf;if(l)for(const s of l)this.validateAndRegisterProperties(s,t,n,r,i,o)}getConfigurationProperties(){return this.configurationProperties}getPolicyConfigurations(){return this.policyConfigurations}registerJSONConfiguration(e){const t=e=>{const n=e.properties;if(n)for(const t in n)this.updateSchema(t,n[t]);const r=e.allOf;r?.forEach(t)};t(e)}updateSchema(e,t){switch(u.properties[e]=t,t.scope){case 1:d.properties[e]=t;break;case 2:g.properties[e]=t;break;case 6:f.properties[e]=t;break;case 3:m.properties[e]=t;break;case 4:p.properties[e]=t;break;case 5:p.properties[e]=t,this.resourceLanguageSettingsSchema.properties[e]=t}}updateOverridePropertyPatternKey(){for(const e of this.overrideIdentifiers.values()){const t=`[${e}]`,n={type:"object",description:o.kg("overrideSettings.defaultDescription","Configure editor settings to be overridden for a language."),errorMessage:o.kg("overrideSettings.errorMessage","This setting does not support per-language configuration."),$ref:b};this.updatePropertyDefaultValue(t,n),u.properties[t]=n,d.properties[t]=n,g.properties[t]=n,f.properties[t]=n,m.properties[t]=n,p.properties[t]=n}}registerOverridePropertyPatternKey(){const e={type:"object",description:o.kg("overrideSettings.defaultDescription","Configure editor settings to be overridden for a language."),errorMessage:o.kg("overrideSettings.errorMessage","This setting does not support per-language configuration."),$ref:b};u.patternProperties[C]=e,d.patternProperties[C]=e,g.patternProperties[C]=e,f.patternProperties[C]=e,m.patternProperties[C]=e,p.patternProperties[C]=e,this._onDidSchemaChange.fire()}updatePropertyDefaultValue(e,t){const n=this.configurationDefaultsOverrides.get(e)?.configurationDefaultOverrideValue;let r,i;!n||t.disallowConfigurationDefault&&n.source||(r=n.value,i=n.source),s.b0(r)&&(r=t.defaultDefaultValue,i=void 0),s.b0(r)&&(r=function(e){switch(Array.isArray(e)?e[0]:e){case"boolean":return!1;case"integer":case"number":return 0;case"string":return"";case"array":return[];case"object":return{};default:return null}}(t.type)),t.default=r,t.defaultValueSource=i}};function S(e,t){return e.trim()?y.test(e)?o.kg("config.property.languageDefault","Cannot register '{0}'. This matches property pattern '\\\\[.*\\\\]$' for describing language specific editor settings. Use 'configurationDefaults' contribution.",e):void 0!==w.getConfigurationProperties()[e]?o.kg("config.property.duplicate","Cannot register '{0}'. This property is already registered.",e):t.policy?.name&&void 0!==w.getPolicyConfigurations().get(t.policy?.name)?o.kg("config.policy.duplicate","Cannot register '{0}'. The associated policy {1} is already registered with {2}.",e,t.policy?.name,w.getPolicyConfigurations().get(t.policy?.name)):null:o.kg("config.property.empty","Cannot register an empty property")}c.O.add(h.Configuration,w)},4621:(e,t,n)=>{"use strict";n.d(t,{v:()=>s});class r{constructor(e,t=[],n=!1){this.ctor=e,this.staticArguments=t,this.supportsDelayedInstantiation=n}}const i=[];function s(e,t,n){t instanceof r||(t=new r(t,[],Boolean(n))),i.push([e,t])}},3591:(e,t,n)=>{"use strict";var r;n.d(t,{_Y:()=>i,u1:()=>s}),function(e){e.serviceIds=new Map,e.DI_TARGET="$di$target",e.DI_DEPENDENCIES="$di$dependencies",e.getServiceDependencies=function(t){return t[e.DI_DEPENDENCIES]||[]}}(r||(r={}));const i=s("instantiationService");function s(e){if(r.serviceIds.has(e))return r.serviceIds.get(e);const t=function(e,n,i){if(3!==arguments.length)throw new Error("@IServiceName-decorator can only be used to decorate a parameter");!function(e,t,n){t[r.DI_TARGET]===t?t[r.DI_DEPENDENCIES].push({id:e,index:n}):(t[r.DI_DEPENDENCIES]=[{id:e,index:n}],t[r.DI_TARGET]=t)}(t,e,i)};return t.toString=()=>e,r.serviceIds.set(e,t),t}},8748:(e,t,n)=>{"use strict";n.d(t,{F:()=>s});var r=n(1234),i=n(6359);const s={JSONContribution:"base.contributions.json"};const o=new class{constructor(){this._onDidChangeSchema=new r.vl,this.schemasById={}}registerSchema(e,t){var n;this.schemasById[(n=e,n.length>0&&"#"===n.charAt(n.length-1)?n.substring(0,n.length-1):n)]=t,this._onDidChangeSchema.fire(e)}notifySchemaChanged(e){this._onDidChangeSchema.fire(e)}};i.O.add(s.JSONContribution,o)},3511:(e,t,n)=>{"use strict";n.d(t,{rr:()=>Q,$b:()=>J});n(1234);var r=n(1484),i=n(8067),s=n(1508),o=n(4383),a=n(8209);function l(...e){switch(e.length){case 1:return(0,a.kg)("contextkey.scanner.hint.didYouMean1","Did you mean {0}?",e[0]);case 2:return(0,a.kg)("contextkey.scanner.hint.didYouMean2","Did you mean {0} or {1}?",e[0],e[1]);case 3:return(0,a.kg)("contextkey.scanner.hint.didYouMean3","Did you mean {0}, {1} or {2}?",e[0],e[1],e[2]);default:return}}const c=(0,a.kg)("contextkey.scanner.hint.didYouForgetToOpenOrCloseQuote","Did you forget to open or close the quote?"),h=(0,a.kg)("contextkey.scanner.hint.didYouForgetToEscapeSlash","Did you forget to escape the '/' (slash) character? Put two backslashes before it to escape, e.g., '\\\\/'.");class u{constructor(){this._input="",this._start=0,this._current=0,this._tokens=[],this._errors=[],this.stringRe=/[a-zA-Z0-9_<>\-\./\\:\*\?\+\[\]\^,#@;"%\$\p{L}-]+/uy}static getLexeme(e){switch(e.type){case 0:return"(";case 1:return")";case 2:return"!";case 3:return e.isTripleEq?"===":"==";case 4:return e.isTripleEq?"!==":"!=";case 5:return"<";case 6:return"<=";case 7:case 8:return">=";case 9:return"=~";case 10:case 17:case 18:case 19:return e.lexeme;case 11:return"true";case 12:return"false";case 13:return"in";case 14:return"not";case 15:return"&&";case 16:return"||";case 20:return"EOF";default:throw(0,o.iH)(`unhandled token type: ${JSON.stringify(e)}; have you forgotten to add a case?`)}}static{this._regexFlags=new Set(["i","g","s","m","y","u"].map((e=>e.charCodeAt(0))))}static{this._keywords=new Map([["not",14],["in",13],["false",12],["true",11]])}reset(e){return this._input=e,this._start=0,this._current=0,this._tokens=[],this._errors=[],this}scan(){for(;!this._isAtEnd();){this._start=this._current;switch(this._advance()){case 40:this._addToken(0);break;case 41:this._addToken(1);break;case 33:if(this._match(61)){const e=this._match(61);this._tokens.push({type:4,offset:this._start,isTripleEq:e})}else this._addToken(2);break;case 39:this._quotedString();break;case 47:this._regex();break;case 61:if(this._match(61)){const e=this._match(61);this._tokens.push({type:3,offset:this._start,isTripleEq:e})}else this._match(126)?this._addToken(9):this._error(l("==","=~"));break;case 60:this._addToken(this._match(61)?6:5);break;case 62:this._addToken(this._match(61)?8:7);break;case 38:this._match(38)?this._addToken(15):this._error(l("&&"));break;case 124:this._match(124)?this._addToken(16):this._error(l("||"));break;case 32:case 13:case 9:case 10:case 160:break;default:this._string()}}return this._start=this._current,this._addToken(20),Array.from(this._tokens)}_match(e){return!this._isAtEnd()&&(this._input.charCodeAt(this._current)===e&&(this._current++,!0))}_advance(){return this._input.charCodeAt(this._current++)}_peek(){return this._isAtEnd()?0:this._input.charCodeAt(this._current)}_addToken(e){this._tokens.push({type:e,offset:this._start})}_error(e){const t=this._start,n=this._input.substring(this._start,this._current),r={type:19,offset:this._start,lexeme:n};this._errors.push({offset:t,lexeme:n,additionalInfo:e}),this._tokens.push(r)}_string(){this.stringRe.lastIndex=this._start;const e=this.stringRe.exec(this._input);if(e){this._current=this._start+e[0].length;const t=this._input.substring(this._start,this._current),n=u._keywords.get(t);n?this._addToken(n):this._tokens.push({type:17,lexeme:t,offset:this._start})}}_quotedString(){for(;39!==this._peek()&&!this._isAtEnd();)this._advance();this._isAtEnd()?this._error(c):(this._advance(),this._tokens.push({type:18,lexeme:this._input.substring(this._start+1,this._current-1),offset:this._start+1}))}_regex(){let e=this._current,t=!1,n=!1;for(;;){if(e>=this._input.length)return this._current=e,void this._error(h);const r=this._input.charCodeAt(e);if(t)t=!1;else{if(47===r&&!n){e++;break}91===r?n=!0:92===r?t=!0:93===r&&(n=!1)}e++}for(;e=this._input.length}}var d=n(3591);const g=new Map;g.set("false",!1),g.set("true",!0),g.set("isMac",i.zx),g.set("isLinux",i.j9),g.set("isWindows",i.uF),g.set("isWeb",i.HZ),g.set("isMacNative",i.zx&&!i.HZ),g.set("isEdge",i.UP),g.set("isFirefox",i.gm),g.set("isChrome",i.H8),g.set("isSafari",i.nr);const f=Object.prototype.hasOwnProperty,m={regexParsingWithErrorRecovery:!0},p=(0,a.kg)("contextkey.parser.error.emptyString","Empty context key expression"),b=(0,a.kg)("contextkey.parser.error.emptyString.hint","Did you forget to write an expression? You can also put 'false' or 'true' to always evaluate to false or true, respectively."),_=(0,a.kg)("contextkey.parser.error.noInAfterNot","'in' after 'not'."),k=(0,a.kg)("contextkey.parser.error.closingParenthesis","closing parenthesis ')'"),v=(0,a.kg)("contextkey.parser.error.unexpectedToken","Unexpected token"),C=(0,a.kg)("contextkey.parser.error.unexpectedToken.hint","Did you forget to put && or || before the token?"),y=(0,a.kg)("contextkey.parser.error.unexpectedEOF","Unexpected end of expression"),L=(0,a.kg)("contextkey.parser.error.unexpectedEOF.hint","Did you forget to put a context key?");class w{static{this._parseError=new Error}constructor(e=m){this._config=e,this._scanner=new u,this._tokens=[],this._current=0,this._parsingErrors=[],this._flagsGYRe=/g|y/g}parse(e){if(""!==e){this._tokens=this._scanner.reset(e).scan(),this._current=0,this._parsingErrors=[];try{const e=this._expr();if(!this._isAtEnd()){const e=this._peek(),t=17===e.type?C:void 0;throw this._parsingErrors.push({message:v,offset:e.offset,lexeme:u.getLexeme(e),additionalInfo:t}),w._parseError}return e}catch(t){if(t!==w._parseError)throw t;return}}else this._parsingErrors.push({message:p,offset:0,lexeme:"",additionalInfo:b})}_expr(){return this._or()}_or(){const e=[this._and()];for(;this._matchOne(16);){const t=this._and();e.push(t)}return 1===e.length?e[0]:S.or(...e)}_and(){const e=[this._term()];for(;this._matchOne(15);){const t=this._term();e.push(t)}return 1===e.length?e[0]:S.and(...e)}_term(){if(this._matchOne(2)){const e=this._peek();switch(e.type){case 11:return this._advance(),E.INSTANCE;case 12:return this._advance(),N.INSTANCE;case 0:{this._advance();const e=this._expr();return this._consume(1,k),e?.negate()}case 17:return this._advance(),R.create(e.lexeme);default:throw this._errExpectedButGot("KEY | true | false | '(' expression ')'",e)}}return this._primary()}_primary(){const e=this._peek();switch(e.type){case 11:return this._advance(),S.true();case 12:return this._advance(),S.false();case 0:{this._advance();const e=this._expr();return this._consume(1,k),e}case 17:{const r=e.lexeme;if(this._advance(),this._matchOne(9)){const e=this._peek();if(!this._config.regexParsingWithErrorRecovery){if(this._advance(),10!==e.type)throw this._errExpectedButGot("REGEX",e);const n=e.lexeme,i=n.lastIndexOf("/"),s=i===n.length-1?void 0:this._removeFlagsGY(n.substring(i+1));let o;try{o=new RegExp(n.substring(1,i),s)}catch(t){throw this._errExpectedButGot("REGEX",e)}return z.create(r,o)}switch(e.type){case 10:case 19:{const n=[e.lexeme];this._advance();let i=this._peek(),s=0;for(let t=0;t=0){const o=t.slice(r+1,s),a="i"===t[s+1]?"i":"";try{i=new RegExp(o,a)}catch(n){throw this._errExpectedButGot("REGEX",e)}}}if(null===i)throw this._errExpectedButGot("REGEX",e);return z.create(r,i)}default:throw this._errExpectedButGot("REGEX",this._peek())}}if(this._matchOne(14)){this._consume(13,_);const e=this._value();return S.notIn(r,e)}switch(this._peek().type){case 3:{this._advance();const e=this._value();if(18===this._previous().type)return S.equals(r,e);switch(e){case"true":return S.has(r);case"false":return S.not(r);default:return S.equals(r,e)}}case 4:{this._advance();const e=this._value();if(18===this._previous().type)return S.notEquals(r,e);switch(e){case"true":return S.not(r);case"false":return S.has(r);default:return S.notEquals(r,e)}}case 5:return this._advance(),P.create(r,this._value());case 6:return this._advance(),V.create(r,this._value());case 7:return this._advance(),B.create(r,this._value());case 8:return this._advance(),F.create(r,this._value());case 13:return this._advance(),S.in(r,this._value());default:return S.has(r)}}case 20:throw this._parsingErrors.push({message:y,offset:e.offset,lexeme:"",additionalInfo:L}),w._parseError;default:throw this._errExpectedButGot("true | false | KEY \n\t| KEY '=~' REGEX \n\t| KEY ('==' | '!=' | '<' | '<=' | '>' | '>=' | 'in' | 'not' 'in') value",this._peek())}}_value(){const e=this._peek();switch(e.type){case 17:case 18:return this._advance(),e.lexeme;case 11:return this._advance(),"true";case 12:return this._advance(),"false";case 13:return this._advance(),"in";default:return""}}_removeFlagsGY(e){return e.replaceAll(this._flagsGYRe,"")}_previous(){return this._tokens[this._current-1]}_matchOne(e){return!!this._check(e)&&(this._advance(),!0)}_advance(){return this._isAtEnd()||this._current++,this._previous()}_consume(e,t){if(this._check(e))return this._advance();throw this._errExpectedButGot(t,this._peek())}_errExpectedButGot(e,t,n){const r=(0,a.kg)("contextkey.parser.error.expectedButGot","Expected: {0}\nReceived: '{1}'.",e,u.getLexeme(t)),i=t.offset,s=u.getLexeme(t);return this._parsingErrors.push({message:r,offset:i,lexeme:s,additionalInfo:n}),w._parseError}_check(e){return this._peek().type===e}_peek(){return this._tokens[this._current]}_isAtEnd(){return 20===this._peek().type}}class S{static false(){return E.INSTANCE}static true(){return N.INSTANCE}static has(e){return T.create(e)}static equals(e,t){return A.create(e,t)}static notEquals(e,t){return M.create(e,t)}static regex(e,t){return z.create(e,t)}static in(e,t){return I.create(e,t)}static notIn(e,t){return O.create(e,t)}static not(e){return R.create(e)}static and(...e){return W.create(e,null,!0)}static or(...e){return U.create(e,null,!0)}static{this._parser=new w({regexParsingWithErrorRecovery:!1})}static deserialize(e){if(void 0===e||null===e)return;return this._parser.parse(e)}}function x(e,t){return e.cmp(t)}class E{static{this.INSTANCE=new E}constructor(){this.type=0}cmp(e){return this.type-e.type}equals(e){return e.type===this.type}substituteConstants(){return this}evaluate(e){return!1}serialize(){return"false"}keys(){return[]}negate(){return N.INSTANCE}}class N{static{this.INSTANCE=new N}constructor(){this.type=1}cmp(e){return this.type-e.type}equals(e){return e.type===this.type}substituteConstants(){return this}evaluate(e){return!0}serialize(){return"true"}keys(){return[]}negate(){return E.INSTANCE}}class T{static create(e,t=null){const n=g.get(e);return"boolean"===typeof n?n?N.INSTANCE:E.INSTANCE:new T(e,t)}constructor(e,t){this.key=e,this.negated=t,this.type=2}cmp(e){return e.type!==this.type?this.type-e.type:H(this.key,e.key)}equals(e){return e.type===this.type&&this.key===e.key}substituteConstants(){const e=g.get(this.key);return"boolean"===typeof e?e?N.INSTANCE:E.INSTANCE:this}evaluate(e){return!!e.getValue(this.key)}serialize(){return this.key}keys(){return[this.key]}negate(){return this.negated||(this.negated=R.create(this.key,this)),this.negated}}class A{static create(e,t,n=null){if("boolean"===typeof t)return t?T.create(e,n):R.create(e,n);const r=g.get(e);if("boolean"===typeof r){return t===(r?"true":"false")?N.INSTANCE:E.INSTANCE}return new A(e,t,n)}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=4}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){const e=g.get(this.key);if("boolean"===typeof e){const t=e?"true":"false";return this.value===t?N.INSTANCE:E.INSTANCE}return this}evaluate(e){return e.getValue(this.key)==this.value}serialize(){return`${this.key} == '${this.value}'`}keys(){return[this.key]}negate(){return this.negated||(this.negated=M.create(this.key,this.value,this)),this.negated}}class I{static create(e,t){return new I(e,t)}constructor(e,t){this.key=e,this.valueKey=t,this.type=10,this.negated=null}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.valueKey,e.key,e.valueKey)}equals(e){return e.type===this.type&&(this.key===e.key&&this.valueKey===e.valueKey)}substituteConstants(){return this}evaluate(e){const t=e.getValue(this.valueKey),n=e.getValue(this.key);return Array.isArray(t)?t.includes(n):"string"===typeof n&&"object"===typeof t&&null!==t&&f.call(t,n)}serialize(){return`${this.key} in '${this.valueKey}'`}keys(){return[this.key,this.valueKey]}negate(){return this.negated||(this.negated=O.create(this.key,this.valueKey)),this.negated}}class O{static create(e,t){return new O(e,t)}constructor(e,t){this.key=e,this.valueKey=t,this.type=11,this._negated=I.create(e,t)}cmp(e){return e.type!==this.type?this.type-e.type:this._negated.cmp(e._negated)}equals(e){return e.type===this.type&&this._negated.equals(e._negated)}substituteConstants(){return this}evaluate(e){return!this._negated.evaluate(e)}serialize(){return`${this.key} not in '${this.valueKey}'`}keys(){return this._negated.keys()}negate(){return this._negated}}class M{static create(e,t,n=null){if("boolean"===typeof t)return t?R.create(e,n):T.create(e,n);const r=g.get(e);if("boolean"===typeof r){return t===(r?"true":"false")?E.INSTANCE:N.INSTANCE}return new M(e,t,n)}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=5}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){const e=g.get(this.key);if("boolean"===typeof e){const t=e?"true":"false";return this.value===t?E.INSTANCE:N.INSTANCE}return this}evaluate(e){return e.getValue(this.key)!=this.value}serialize(){return`${this.key} != '${this.value}'`}keys(){return[this.key]}negate(){return this.negated||(this.negated=A.create(this.key,this.value,this)),this.negated}}class R{static create(e,t=null){const n=g.get(e);return"boolean"===typeof n?n?E.INSTANCE:N.INSTANCE:new R(e,t)}constructor(e,t){this.key=e,this.negated=t,this.type=3}cmp(e){return e.type!==this.type?this.type-e.type:H(this.key,e.key)}equals(e){return e.type===this.type&&this.key===e.key}substituteConstants(){const e=g.get(this.key);return"boolean"===typeof e?e?E.INSTANCE:N.INSTANCE:this}evaluate(e){return!e.getValue(this.key)}serialize(){return`!${this.key}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=T.create(this.key,this)),this.negated}}function D(e,t){if("string"===typeof e){const t=parseFloat(e);isNaN(t)||(e=t)}return"string"===typeof e||"number"===typeof e?t(e):E.INSTANCE}class B{static create(e,t,n=null){return D(t,(t=>new B(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=12}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))>this.value}serialize(){return`${this.key} > ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=V.create(this.key,this.value,this)),this.negated}}class F{static create(e,t,n=null){return D(t,(t=>new F(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=13}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))>=this.value}serialize(){return`${this.key} >= ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=P.create(this.key,this.value,this)),this.negated}}class P{static create(e,t,n=null){return D(t,(t=>new P(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=14}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))new V(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=15}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))<=this.value}serialize(){return`${this.key} <= ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=B.create(this.key,this.value,this)),this.negated}}class z{static create(e,t){return new z(e,t)}constructor(e,t){this.key=e,this.regexp=t,this.type=7,this.negated=null}cmp(e){if(e.type!==this.type)return this.type-e.type;if(this.keye.key)return 1;const t=this.regexp?this.regexp.source:"",n=e.regexp?e.regexp.source:"";return tn?1:0}equals(e){if(e.type===this.type){const t=this.regexp?this.regexp.source:"",n=e.regexp?e.regexp.source:"";return this.key===e.key&&t===n}return!1}substituteConstants(){return this}evaluate(e){const t=e.getValue(this.key);return!!this.regexp&&this.regexp.test(t)}serialize(){const e=this.regexp?`/${this.regexp.source}/${this.regexp.flags}`:"/invalid/";return`${this.key} =~ ${e}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=j.create(this)),this.negated}}class j{static create(e){return new j(e)}constructor(e){this._actual=e,this.type=8}cmp(e){return e.type!==this.type?this.type-e.type:this._actual.cmp(e._actual)}equals(e){return e.type===this.type&&this._actual.equals(e._actual)}substituteConstants(){return this}evaluate(e){return!this._actual.evaluate(e)}serialize(){return`!(${this._actual.serialize()})`}keys(){return this._actual.keys()}negate(){return this._actual}}function q(e){let t=null;for(let n=0,r=e.length;ne.expr.length)return 1;for(let t=0,n=this.expr.length;t1;){const e=r[r.length-1];if(9!==e.type)break;r.pop();const t=r.pop(),i=0===r.length,s=U.create(e.expr.map((e=>W.create([e,t],null,n))),null,i);s&&(r.push(s),r.sort(x))}if(1===r.length)return r[0];if(n){for(let e=0;ee.serialize())).join(" && ")}keys(){const e=[];for(const t of this.expr)e.push(...t.keys());return e}negate(){if(!this.negated){const e=[];for(const t of this.expr)e.push(t.negate());this.negated=U.create(e,this,!0)}return this.negated}}class U{static create(e,t,n){return U._normalizeArr(e,t,n)}constructor(e,t){this.expr=e,this.negated=t,this.type=9}cmp(e){if(e.type!==this.type)return this.type-e.type;if(this.expr.lengthe.expr.length)return 1;for(let t=0,n=this.expr.length;te.serialize())).join(" || ")}keys(){const e=[];for(const t of this.expr)e.push(...t.keys());return e}negate(){if(!this.negated){const e=[];for(const t of this.expr)e.push(t.negate());for(;e.length>1;){const t=e.shift(),n=e.shift(),r=[];for(const e of G(t))for(const t of G(n))r.push(W.create([e,t],null,!1));e.unshift(U.create(r,null,!1))}this.negated=U.create(e,this,!0)}return this.negated}}class $ extends T{static{this._info=[]}static all(){return $._info.values()}constructor(e,t,n){super(e,null),this._defaultValue=t,"object"===typeof n?$._info.push({...n,key:e}):!0!==n&&$._info.push({key:e,description:n,type:null!==t&&void 0!==t?typeof t:void 0})}bindTo(e){return e.createKey(this.key,this._defaultValue)}getValue(e){return e.getContextKeyValue(this.key)}toNegated(){return this.negate()}isEqualTo(e){return A.create(this.key,e)}}(0,d.u1)("contextKeyService");function H(e,t){return et?1:0}function K(e,t,n,r){return en?1:tr?1:0}function G(e){return 9===e.type?e.expr:[e]}const Q=(0,d.u1)("logService");var J;!function(e){e[e.Off=0]="Off",e[e.Trace=1]="Trace",e[e.Debug=2]="Debug",e[e.Info=3]="Info",e[e.Warning=4]="Warning",e[e.Error=5]="Error"}(J||(J={}));J.Info;r.jG;new $("logLevel",function(e){switch(e){case J.Trace:return"trace";case J.Debug:return"debug";case J.Info:return"info";case J.Warning:return"warn";case J.Error:return"error";case J.Off:return"off"}}(J.Info))},6359:(e,t,n)=>{"use strict";n.d(t,{O:()=>s});var r=n(6782),i=n(631);const s=new class{constructor(){this.data=new Map}add(e,t){r.ok(i.Kg(e)),r.ok(i.Gv(t)),r.ok(!this.data.has(e),"There is already an extension with this id"),this.data.set(e,t)}as(e){return this.data.get(e)||null}}},5845:(e,t,n)=>{"use strict";n.d(t,{buw:()=>S,b1q:()=>w,YtV:()=>I,Ubg:()=>q,IIb:()=>z,pOz:()=>V,whs:()=>B,Stt:()=>P,Hng:()=>F,yLC:()=>le,KoI:()=>oe,uMG:()=>ae,x1A:()=>u});var r=n(6782),i=n(1940),s=n(7661),o=n(1234),a=n(8748),l=n(6359),c=n(8209);const h=new class{constructor(){this._onDidChangeSchema=new o.vl,this.onDidChangeSchema=this._onDidChangeSchema.event,this.colorSchema={type:"object",properties:{}},this.colorReferenceSchema={type:"string",enum:[],enumDescriptions:[]},this.colorsById={}}registerColor(e,t,n,r=!1,i){const s={id:e,description:n,defaults:t,needsTransparency:r,deprecationMessage:i};this.colorsById[e]=s;const o={type:"string",format:"color-hex",defaultSnippets:[{body:"${1:#ff0000}"}]};return i&&(o.deprecationMessage=i),r&&(o.pattern="^#(?:(?[0-9a-fA-f]{3}[0-9a-eA-E])|(?:[0-9a-fA-F]{6}(?:(?![fF]{2})(?:[0-9a-fA-F]{2}))))?$",o.patternErrorMessage=c.kg("transparecyRequired","This color must be transparent or it will obscure content")),this.colorSchema.properties[e]={description:n,oneOf:[o,{type:"string",const:"default",description:c.kg("useDefault","Use the default color.")}]},this.colorReferenceSchema.enum.push(e),this.colorReferenceSchema.enumDescriptions.push(n),this._onDidChangeSchema.fire(),e}getColors(){return Object.keys(this.colorsById).map((e=>this.colorsById[e]))}resolveDefaultColor(e,t){const n=this.colorsById[e];if(n?.defaults){return b(null!==(r=n.defaults)&&"object"===typeof r&&"light"in r&&"dark"in r?n.defaults[t.type]:n.defaults,t)}var r}getColorSchema(){return this.colorSchema}toString(){return Object.keys(this.colorsById).sort(((e,t)=>{const n=-1===e.indexOf(".")?0:1,r=-1===t.indexOf(".")?0:1;return n!==r?n-r:e.localeCompare(t)})).map((e=>`- \`${e}\`: ${this.colorsById[e].description}`)).join("\n")}};function u(e,t,n,r,i){return h.registerColor(e,t,n,r,i)}function d(e,t){return{op:0,value:e,factor:t}}function g(e,t){return{op:1,value:e,factor:t}}function f(e,t){return{op:2,value:e,factor:t}}function m(...e){return{op:4,values:e}}function p(e,t,n,r){return{op:5,value:e,background:t,factor:n,transparency:r}}function b(e,t){if(null!==e)return"string"===typeof e?"#"===e[0]?s.Q1.fromHex(e):t.getColor(e):e instanceof s.Q1?e:"object"===typeof e?function(e,t){switch(e.op){case 0:return b(e.value,t)?.darken(e.factor);case 1:return b(e.value,t)?.lighten(e.factor);case 2:return b(e.value,t)?.transparent(e.factor);case 3:{const n=b(e.background,t);return n?b(e.value,t)?.makeOpaque(n):b(e.value,t)}case 4:for(const n of e.values){const e=b(n,t);if(e)return e}return;case 6:return b(t.defines(e.if)?e.then:e.else,t);case 5:{const n=b(e.value,t);if(!n)return;const r=b(e.background,t);return r?n.isDarkerThan(r)?s.Q1.getLighterColor(n,r,e.factor).transparent(e.transparency):s.Q1.getDarkerColor(n,r,e.factor).transparent(e.transparency):n.transparent(e.factor*e.transparency)}default:throw(0,r.xb)(e)}}(e,t):void 0}l.O.add("base.contributions.colors",h);const _="vscode://schemas/workbench-colors",k=l.O.as(a.F.JSONContribution);k.registerSchema(_,h.getColorSchema());const v=new i.uC((()=>k.notifySchemaChanged(_)),200);h.onDidChangeSchema((()=>{v.isScheduled()||v.schedule()}));const C=u("foreground",{dark:"#CCCCCC",light:"#616161",hcDark:"#FFFFFF",hcLight:"#292929"},c.kg("foreground","Overall foreground color. This color is only used if not overridden by a component.")),y=(u("disabledForeground",{dark:"#CCCCCC80",light:"#61616180",hcDark:"#A5A5A5",hcLight:"#7F7F7F"},c.kg("disabledForeground","Overall foreground for disabled elements. This color is only used if not overridden by a component.")),u("errorForeground",{dark:"#F48771",light:"#A1260D",hcDark:"#F48771",hcLight:"#B5200D"},c.kg("errorForeground","Overall foreground color for error messages. This color is only used if not overridden by a component.")),u("descriptionForeground",{light:"#717171",dark:f(C,.7),hcDark:f(C,.7),hcLight:f(C,.7)},c.kg("descriptionForeground","Foreground color for description text providing additional information, for example for a label.")),u("icon.foreground",{dark:"#C5C5C5",light:"#424242",hcDark:"#FFFFFF",hcLight:"#292929"},c.kg("iconForeground","The default color for icons in the workbench."))),L=u("focusBorder",{dark:"#007FD4",light:"#0090F1",hcDark:"#F38518",hcLight:"#006BBD"},c.kg("focusBorder","Overall border color for focused elements. This color is only used if not overridden by a component.")),w=u("contrastBorder",{light:null,dark:null,hcDark:"#6FC3DF",hcLight:"#0F4A85"},c.kg("contrastBorder","An extra border around elements to separate them from others for greater contrast.")),S=u("contrastActiveBorder",{light:null,dark:null,hcDark:L,hcLight:L},c.kg("activeContrastBorder","An extra border around active elements to separate them from others for greater contrast.")),x=(u("selection.background",null,c.kg("selectionBackground","The background color of text selections in the workbench (e.g. for input fields or text areas). Note that this does not apply to selections within the editor.")),u("textLink.foreground",{light:"#006AB1",dark:"#3794FF",hcDark:"#21A6FF",hcLight:"#0F4A85"},c.kg("textLinkForeground","Foreground color for links in text.")),u("textLink.activeForeground",{light:"#006AB1",dark:"#3794FF",hcDark:"#21A6FF",hcLight:"#0F4A85"},c.kg("textLinkActiveForeground","Foreground color for links in text when clicked on and on mouse hover.")),u("textSeparator.foreground",{light:"#0000002e",dark:"#ffffff2e",hcDark:s.Q1.black,hcLight:"#292929"},c.kg("textSeparatorForeground","Color for text separators.")),u("textPreformat.foreground",{light:"#A31515",dark:"#D7BA7D",hcDark:"#000000",hcLight:"#FFFFFF"},c.kg("textPreformatForeground","Foreground color for preformatted text segments.")),u("textPreformat.background",{light:"#0000001A",dark:"#FFFFFF1A",hcDark:"#FFFFFF",hcLight:"#09345f"},c.kg("textPreformatBackground","Background color for preformatted text segments.")),u("textBlockQuote.background",{light:"#f2f2f2",dark:"#222222",hcDark:null,hcLight:"#F2F2F2"},c.kg("textBlockQuoteBackground","Background color for block quotes in text.")),u("textBlockQuote.border",{light:"#007acc80",dark:"#007acc80",hcDark:s.Q1.white,hcLight:"#292929"},c.kg("textBlockQuoteBorder","Border color for block quotes in text.")),u("textCodeBlock.background",{light:"#dcdcdc66",dark:"#0a0a0a66",hcDark:s.Q1.black,hcLight:"#F2F2F2"},c.kg("textCodeBlockBackground","Background color for code blocks in text.")),u("sash.hoverBorder",L,c.kg("sashActiveBorder","Border color of active sashes.")),u("badge.background",{dark:"#4D4D4D",light:"#C4C4C4",hcDark:s.Q1.black,hcLight:"#0F4A85"},c.kg("badgeBackground","Badge background color. Badges are small information labels, e.g. for search results count."))),E=(u("badge.foreground",{dark:s.Q1.white,light:"#333",hcDark:s.Q1.white,hcLight:s.Q1.white},c.kg("badgeForeground","Badge foreground color. Badges are small information labels, e.g. for search results count.")),u("scrollbar.shadow",{dark:"#000000",light:"#DDDDDD",hcDark:null,hcLight:null},c.kg("scrollbarShadow","Scrollbar shadow to indicate that the view is scrolled."))),N=u("scrollbarSlider.background",{dark:s.Q1.fromHex("#797979").transparent(.4),light:s.Q1.fromHex("#646464").transparent(.4),hcDark:f(w,.6),hcLight:f(w,.4)},c.kg("scrollbarSliderBackground","Scrollbar slider background color.")),T=u("scrollbarSlider.hoverBackground",{dark:s.Q1.fromHex("#646464").transparent(.7),light:s.Q1.fromHex("#646464").transparent(.7),hcDark:f(w,.8),hcLight:f(w,.8)},c.kg("scrollbarSliderHoverBackground","Scrollbar slider background color when hovering.")),A=u("scrollbarSlider.activeBackground",{dark:s.Q1.fromHex("#BFBFBF").transparent(.4),light:s.Q1.fromHex("#000000").transparent(.6),hcDark:w,hcLight:w},c.kg("scrollbarSliderActiveBackground","Scrollbar slider background color when clicked on.")),I=(u("progressBar.background",{dark:s.Q1.fromHex("#0E70C0"),light:s.Q1.fromHex("#0E70C0"),hcDark:w,hcLight:w},c.kg("progressBarBackground","Background color of the progress bar that can show for long running operations.")),u("editor.background",{light:"#ffffff",dark:"#1E1E1E",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("editorBackground","Editor background color."))),O=(u("editor.foreground",{light:"#333333",dark:"#BBBBBB",hcDark:s.Q1.white,hcLight:C},c.kg("editorForeground","Editor default foreground color.")),u("editorStickyScroll.background",I,c.kg("editorStickyScrollBackground","Background color of sticky scroll in the editor")),u("editorStickyScrollHover.background",{dark:"#2A2D2E",light:"#F0F0F0",hcDark:null,hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("editorStickyScrollHoverBackground","Background color of sticky scroll on hover in the editor")),u("editorStickyScroll.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("editorStickyScrollBorder","Border color of sticky scroll in the editor")),u("editorStickyScroll.shadow",E,c.kg("editorStickyScrollShadow"," Shadow color of sticky scroll in the editor")),u("editorWidget.background",{dark:"#252526",light:"#F3F3F3",hcDark:"#0C141F",hcLight:s.Q1.white},c.kg("editorWidgetBackground","Background color of editor widgets, such as find/replace."))),M=u("editorWidget.foreground",C,c.kg("editorWidgetForeground","Foreground color of editor widgets, such as find/replace.")),R=u("editorWidget.border",{dark:"#454545",light:"#C8C8C8",hcDark:w,hcLight:w},c.kg("editorWidgetBorder","Border color of editor widgets. The color is only used if the widget chooses to have a border and if the color is not overridden by a widget.")),D=(u("editorWidget.resizeBorder",null,c.kg("editorWidgetResizeBorder","Border color of the resize bar of editor widgets. The color is only used if the widget chooses to have a resize border and if the color is not overridden by a widget.")),u("editorError.background",null,c.kg("editorError.background","Background color of error text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorError.foreground",{dark:"#F14C4C",light:"#E51400",hcDark:"#F48771",hcLight:"#B5200D"},c.kg("editorError.foreground","Foreground color of error squigglies in the editor."))),B=(u("editorError.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#E47777").transparent(.8),hcLight:"#B5200D"},c.kg("errorBorder","If set, color of double underlines for errors in the editor.")),u("editorWarning.background",null,c.kg("editorWarning.background","Background color of warning text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0)),F=u("editorWarning.foreground",{dark:"#CCA700",light:"#BF8803",hcDark:"#FFD370",hcLight:"#895503"},c.kg("editorWarning.foreground","Foreground color of warning squigglies in the editor.")),P=u("editorWarning.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#FFCC00").transparent(.8),hcLight:s.Q1.fromHex("#FFCC00").transparent(.8)},c.kg("warningBorder","If set, color of double underlines for warnings in the editor.")),V=(u("editorInfo.background",null,c.kg("editorInfo.background","Background color of info text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorInfo.foreground",{dark:"#3794FF",light:"#1a85ff",hcDark:"#3794FF",hcLight:"#1a85ff"},c.kg("editorInfo.foreground","Foreground color of info squigglies in the editor."))),z=u("editorInfo.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#3794FF").transparent(.8),hcLight:"#292929"},c.kg("infoBorder","If set, color of double underlines for infos in the editor.")),j=(u("editorHint.foreground",{dark:s.Q1.fromHex("#eeeeee").transparent(.7),light:"#6c6c6c",hcDark:null,hcLight:null},c.kg("editorHint.foreground","Foreground color of hint squigglies in the editor.")),u("editorHint.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#eeeeee").transparent(.8),hcLight:"#292929"},c.kg("hintBorder","If set, color of double underlines for hints in the editor.")),u("editorLink.activeForeground",{dark:"#4E94CE",light:s.Q1.blue,hcDark:s.Q1.cyan,hcLight:"#292929"},c.kg("activeLinkForeground","Color of active links.")),u("editor.selectionBackground",{light:"#ADD6FF",dark:"#264F78",hcDark:"#f3f518",hcLight:"#0F4A85"},c.kg("editorSelectionBackground","Color of the editor selection."))),q=(u("editor.selectionForeground",{light:null,dark:null,hcDark:"#000000",hcLight:s.Q1.white},c.kg("editorSelectionForeground","Color of the selected text for high contrast.")),u("editor.inactiveSelectionBackground",{light:f(j,.5),dark:f(j,.5),hcDark:f(j,.7),hcLight:f(j,.5)},c.kg("editorInactiveSelection","Color of the selection in an inactive editor. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.selectionHighlightBackground",{light:p(j,I,.3,.6),dark:p(j,I,.3,.6),hcDark:null,hcLight:null},c.kg("editorSelectionHighlight","Color for regions with the same content as the selection. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.selectionHighlightBorder",{light:null,dark:null,hcDark:S,hcLight:S},c.kg("editorSelectionHighlightBorder","Border color for regions with the same content as the selection.")),u("editor.findMatchBackground",{light:"#A8AC94",dark:"#515C6A",hcDark:null,hcLight:null},c.kg("editorFindMatch","Color of the current search match.")),u("editor.findMatchForeground",null,c.kg("editorFindMatchForeground","Text color of the current search match.")),u("editor.findMatchHighlightBackground",{light:"#EA5C0055",dark:"#EA5C0055",hcDark:null,hcLight:null},c.kg("findMatchHighlight","Color of the other search matches. The color must not be opaque so as not to hide underlying decorations."),!0)),W=(u("editor.findMatchHighlightForeground",null,c.kg("findMatchHighlightForeground","Foreground color of the other search matches."),!0),u("editor.findRangeHighlightBackground",{dark:"#3a3d4166",light:"#b4b4b44d",hcDark:null,hcLight:null},c.kg("findRangeHighlight","Color of the range limiting the search. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.findMatchBorder",{light:null,dark:null,hcDark:S,hcLight:S},c.kg("editorFindMatchBorder","Border color of the current search match.")),u("editor.findMatchHighlightBorder",{light:null,dark:null,hcDark:S,hcLight:S},c.kg("findMatchHighlightBorder","Border color of the other search matches."))),U=(u("editor.findRangeHighlightBorder",{dark:null,light:null,hcDark:f(S,.4),hcLight:f(S,.4)},c.kg("findRangeHighlightBorder","Border color of the range limiting the search. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.hoverHighlightBackground",{light:"#ADD6FF26",dark:"#264f7840",hcDark:"#ADD6FF26",hcLight:null},c.kg("hoverHighlight","Highlight below the word for which a hover is shown. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorHoverWidget.background",O,c.kg("hoverBackground","Background color of the editor hover."))),$=(u("editorHoverWidget.foreground",M,c.kg("hoverForeground","Foreground color of the editor hover.")),u("editorHoverWidget.border",R,c.kg("hoverBorder","Border color of the editor hover.")),u("editorHoverWidget.statusBarBackground",{dark:g(U,.2),light:d(U,.05),hcDark:O,hcLight:O},c.kg("statusBarBackground","Background color of the editor hover status bar.")),u("editorInlayHint.foreground",{dark:"#969696",light:"#969696",hcDark:s.Q1.white,hcLight:s.Q1.black},c.kg("editorInlayHintForeground","Foreground color of inline hints"))),H=u("editorInlayHint.background",{dark:f(x,.1),light:f(x,.1),hcDark:f(s.Q1.white,.1),hcLight:f(x,.1)},c.kg("editorInlayHintBackground","Background color of inline hints")),K=(u("editorInlayHint.typeForeground",$,c.kg("editorInlayHintForegroundTypes","Foreground color of inline hints for types")),u("editorInlayHint.typeBackground",H,c.kg("editorInlayHintBackgroundTypes","Background color of inline hints for types")),u("editorInlayHint.parameterForeground",$,c.kg("editorInlayHintForegroundParameter","Foreground color of inline hints for parameters")),u("editorInlayHint.parameterBackground",H,c.kg("editorInlayHintBackgroundParameter","Background color of inline hints for parameters")),u("editorLightBulb.foreground",{dark:"#FFCC00",light:"#DDB100",hcDark:"#FFCC00",hcLight:"#007ACC"},c.kg("editorLightBulbForeground","The color used for the lightbulb actions icon."))),G=(u("editorLightBulbAutoFix.foreground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},c.kg("editorLightBulbAutoFixForeground","The color used for the lightbulb auto fix actions icon.")),u("editorLightBulbAi.foreground",K,c.kg("editorLightBulbAiForeground","The color used for the lightbulb AI icon.")),u("editor.snippetTabstopHighlightBackground",{dark:new s.Q1(new s.bU(124,124,124,.3)),light:new s.Q1(new s.bU(10,50,100,.2)),hcDark:new s.Q1(new s.bU(124,124,124,.3)),hcLight:new s.Q1(new s.bU(10,50,100,.2))},c.kg("snippetTabstopHighlightBackground","Highlight background color of a snippet tabstop.")),u("editor.snippetTabstopHighlightBorder",null,c.kg("snippetTabstopHighlightBorder","Highlight border color of a snippet tabstop.")),u("editor.snippetFinalTabstopHighlightBackground",null,c.kg("snippetFinalTabstopHighlightBackground","Highlight background color of the final tabstop of a snippet.")),u("editor.snippetFinalTabstopHighlightBorder",{dark:"#525252",light:new s.Q1(new s.bU(10,50,100,.5)),hcDark:"#525252",hcLight:"#292929"},c.kg("snippetFinalTabstopHighlightBorder","Highlight border color of the final tabstop of a snippet.")),new s.Q1(new s.bU(155,185,85,.2))),Q=new s.Q1(new s.bU(255,0,0,.2)),J=(u("diffEditor.insertedTextBackground",{dark:"#9ccc2c33",light:"#9ccc2c40",hcDark:null,hcLight:null},c.kg("diffEditorInserted","Background color for text that got inserted. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditor.removedTextBackground",{dark:"#ff000033",light:"#ff000033",hcDark:null,hcLight:null},c.kg("diffEditorRemoved","Background color for text that got removed. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditor.insertedLineBackground",{dark:G,light:G,hcDark:null,hcLight:null},c.kg("diffEditorInsertedLines","Background color for lines that got inserted. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditor.removedLineBackground",{dark:Q,light:Q,hcDark:null,hcLight:null},c.kg("diffEditorRemovedLines","Background color for lines that got removed. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditorGutter.insertedLineBackground",null,c.kg("diffEditorInsertedLineGutter","Background color for the margin where lines got inserted.")),u("diffEditorGutter.removedLineBackground",null,c.kg("diffEditorRemovedLineGutter","Background color for the margin where lines got removed.")),u("diffEditorOverview.insertedForeground",null,c.kg("diffEditorOverviewInserted","Diff overview ruler foreground for inserted content.")),u("diffEditorOverview.removedForeground",null,c.kg("diffEditorOverviewRemoved","Diff overview ruler foreground for removed content.")),u("diffEditor.insertedTextBorder",{dark:null,light:null,hcDark:"#33ff2eff",hcLight:"#374E06"},c.kg("diffEditorInsertedOutline","Outline color for the text that got inserted.")),u("diffEditor.removedTextBorder",{dark:null,light:null,hcDark:"#FF008F",hcLight:"#AD0707"},c.kg("diffEditorRemovedOutline","Outline color for text that got removed.")),u("diffEditor.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("diffEditorBorder","Border color between the two text editors.")),u("diffEditor.diagonalFill",{dark:"#cccccc33",light:"#22222233",hcDark:null,hcLight:null},c.kg("diffDiagonalFill","Color of the diff editor's diagonal fill. The diagonal fill is used in side-by-side diff views.")),u("diffEditor.unchangedRegionBackground","sideBar.background",c.kg("diffEditor.unchangedRegionBackground","The background color of unchanged blocks in the diff editor.")),u("diffEditor.unchangedRegionForeground","foreground",c.kg("diffEditor.unchangedRegionForeground","The foreground color of unchanged blocks in the diff editor.")),u("diffEditor.unchangedCodeBackground",{dark:"#74747429",light:"#b8b8b829",hcDark:null,hcLight:null},c.kg("diffEditor.unchangedCodeBackground","The background color of unchanged code in the diff editor.")),u("widget.shadow",{dark:f(s.Q1.black,.36),light:f(s.Q1.black,.16),hcDark:null,hcLight:null},c.kg("widgetShadow","Shadow color of widgets such as find/replace inside the editor."))),X=(u("widget.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("widgetBorder","Border color of widgets such as find/replace inside the editor.")),u("toolbar.hoverBackground",{dark:"#5a5d5e50",light:"#b8b8b850",hcDark:null,hcLight:null},c.kg("toolbarHoverBackground","Toolbar background when hovering over actions using the mouse"))),Y=(u("toolbar.hoverOutline",{dark:null,light:null,hcDark:S,hcLight:S},c.kg("toolbarHoverOutline","Toolbar outline when hovering over actions using the mouse")),u("toolbar.activeBackground",{dark:g(X,.1),light:d(X,.1),hcDark:null,hcLight:null},c.kg("toolbarActiveBackground","Toolbar background when holding the mouse over actions")),u("breadcrumb.foreground",f(C,.8),c.kg("breadcrumbsFocusForeground","Color of focused breadcrumb items.")),u("breadcrumb.background",I,c.kg("breadcrumbsBackground","Background color of breadcrumb items.")),u("breadcrumb.focusForeground",{light:d(C,.2),dark:g(C,.1),hcDark:g(C,.1),hcLight:g(C,.1)},c.kg("breadcrumbsFocusForeground","Color of focused breadcrumb items.")),u("breadcrumb.activeSelectionForeground",{light:d(C,.2),dark:g(C,.1),hcDark:g(C,.1),hcLight:g(C,.1)},c.kg("breadcrumbsSelectedForeground","Color of selected breadcrumb items.")),u("breadcrumbPicker.background",O,c.kg("breadcrumbsSelectedBackground","Background color of breadcrumb item picker.")),s.Q1.fromHex("#40C8AE").transparent(.5)),Z=s.Q1.fromHex("#40A6FF").transparent(.5),ee=s.Q1.fromHex("#606060").transparent(.4),te=u("merge.currentHeaderBackground",{dark:Y,light:Y,hcDark:null,hcLight:null},c.kg("mergeCurrentHeaderBackground","Current header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),ne=(u("merge.currentContentBackground",f(te,.4),c.kg("mergeCurrentContentBackground","Current content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),u("merge.incomingHeaderBackground",{dark:Z,light:Z,hcDark:null,hcLight:null},c.kg("mergeIncomingHeaderBackground","Incoming header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0)),re=(u("merge.incomingContentBackground",f(ne,.4),c.kg("mergeIncomingContentBackground","Incoming content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),u("merge.commonHeaderBackground",{dark:ee,light:ee,hcDark:null,hcLight:null},c.kg("mergeCommonHeaderBackground","Common ancestor header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0)),ie=(u("merge.commonContentBackground",f(re,.4),c.kg("mergeCommonContentBackground","Common ancestor content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),u("merge.border",{dark:null,light:null,hcDark:"#C3DF6F",hcLight:"#007ACC"},c.kg("mergeBorder","Border color on headers and the splitter in inline merge-conflicts."))),se=(u("editorOverviewRuler.currentContentForeground",{dark:f(te,1),light:f(te,1),hcDark:ie,hcLight:ie},c.kg("overviewRulerCurrentContentForeground","Current overview ruler foreground for inline merge-conflicts.")),u("editorOverviewRuler.incomingContentForeground",{dark:f(ne,1),light:f(ne,1),hcDark:ie,hcLight:ie},c.kg("overviewRulerIncomingContentForeground","Incoming overview ruler foreground for inline merge-conflicts.")),u("editorOverviewRuler.commonContentForeground",{dark:f(re,1),light:f(re,1),hcDark:ie,hcLight:ie},c.kg("overviewRulerCommonContentForeground","Common ancestor overview ruler foreground for inline merge-conflicts.")),u("editorOverviewRuler.findMatchForeground",{dark:"#d186167e",light:"#d186167e",hcDark:"#AB5A00",hcLight:"#AB5A00"},c.kg("overviewRulerFindMatchForeground","Overview ruler marker color for find matches. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorOverviewRuler.selectionHighlightForeground","#A0A0A0CC",c.kg("overviewRulerSelectionHighlightForeground","Overview ruler marker color for selection highlights. The color must not be opaque so as not to hide underlying decorations."),!0),u("problemsErrorIcon.foreground",D,c.kg("problemsErrorIconForeground","The color used for the problems error icon.")),u("problemsWarningIcon.foreground",F,c.kg("problemsWarningIconForeground","The color used for the problems warning icon.")),u("problemsInfoIcon.foreground",V,c.kg("problemsInfoIconForeground","The color used for the problems info icon.")),u("minimap.findMatchHighlight",{light:"#d18616",dark:"#d18616",hcDark:"#AB5A00",hcLight:"#0F4A85"},c.kg("minimapFindMatchHighlight","Minimap marker color for find matches."),!0)),oe=(u("minimap.selectionOccurrenceHighlight",{light:"#c9c9c9",dark:"#676767",hcDark:"#ffffff",hcLight:"#0F4A85"},c.kg("minimapSelectionOccurrenceHighlight","Minimap marker color for repeating editor selections."),!0),u("minimap.selectionHighlight",{light:"#ADD6FF",dark:"#264F78",hcDark:"#ffffff",hcLight:"#0F4A85"},c.kg("minimapSelectionHighlight","Minimap marker color for the editor selection."),!0),u("minimap.infoHighlight",{dark:V,light:V,hcDark:z,hcLight:z},c.kg("minimapInfo","Minimap marker color for infos."))),ae=u("minimap.warningHighlight",{dark:F,light:F,hcDark:P,hcLight:P},c.kg("overviewRuleWarning","Minimap marker color for warnings.")),le=u("minimap.errorHighlight",{dark:new s.Q1(new s.bU(255,18,18,.7)),light:new s.Q1(new s.bU(255,18,18,.7)),hcDark:new s.Q1(new s.bU(255,50,50,1)),hcLight:"#B5200D"},c.kg("minimapError","Minimap marker color for errors.")),ce=(u("minimap.background",null,c.kg("minimapBackground","Minimap background color.")),u("minimap.foregroundOpacity",s.Q1.fromHex("#000f"),c.kg("minimapForegroundOpacity",'Opacity of foreground elements rendered in the minimap. For example, "#000000c0" will render the elements with 75% opacity.')),u("minimapSlider.background",f(N,.5),c.kg("minimapSliderBackground","Minimap slider background color.")),u("minimapSlider.hoverBackground",f(T,.5),c.kg("minimapSliderHoverBackground","Minimap slider background color when hovering.")),u("minimapSlider.activeBackground",f(A,.5),c.kg("minimapSliderActiveBackground","Minimap slider background color when clicked on.")),u("charts.foreground",C,c.kg("chartsForeground","The foreground color used in charts.")),u("charts.lines",f(C,.5),c.kg("chartsLines","The color used for horizontal lines in charts.")),u("charts.red",D,c.kg("chartsRed","The red color used in chart visualizations.")),u("charts.blue",V,c.kg("chartsBlue","The blue color used in chart visualizations.")),u("charts.yellow",F,c.kg("chartsYellow","The yellow color used in chart visualizations.")),u("charts.orange",se,c.kg("chartsOrange","The orange color used in chart visualizations.")),u("charts.green",{dark:"#89D185",light:"#388A34",hcDark:"#89D185",hcLight:"#374e06"},c.kg("chartsGreen","The green color used in chart visualizations.")),u("charts.purple",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},c.kg("chartsPurple","The purple color used in chart visualizations.")),u("input.background",{dark:"#3C3C3C",light:s.Q1.white,hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputBoxBackground","Input box background.")),u("input.foreground",C,c.kg("inputBoxForeground","Input box foreground.")),u("input.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("inputBoxBorder","Input box border.")),u("inputOption.activeBorder",{dark:"#007ACC",light:"#007ACC",hcDark:w,hcLight:w},c.kg("inputBoxActiveOptionBorder","Border color of activated options in input fields."))),he=u("inputOption.hoverBackground",{dark:"#5a5d5e80",light:"#b8b8b850",hcDark:null,hcLight:null},c.kg("inputOption.hoverBackground","Background color of activated options in input fields.")),ue=u("inputOption.activeBackground",{dark:f(L,.4),light:f(L,.2),hcDark:s.Q1.transparent,hcLight:s.Q1.transparent},c.kg("inputOption.activeBackground","Background hover color of options in input fields.")),de=u("inputOption.activeForeground",{dark:s.Q1.white,light:s.Q1.black,hcDark:C,hcLight:C},c.kg("inputOption.activeForeground","Foreground color of activated options in input fields.")),ge=(u("input.placeholderForeground",{light:f(C,.5),dark:f(C,.5),hcDark:f(C,.7),hcLight:f(C,.7)},c.kg("inputPlaceholderForeground","Input box foreground color for placeholder text.")),u("inputValidation.infoBackground",{dark:"#063B49",light:"#D6ECF2",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputValidationInfoBackground","Input validation background color for information severity.")),u("inputValidation.infoForeground",{dark:null,light:null,hcDark:null,hcLight:C},c.kg("inputValidationInfoForeground","Input validation foreground color for information severity.")),u("inputValidation.infoBorder",{dark:"#007acc",light:"#007acc",hcDark:w,hcLight:w},c.kg("inputValidationInfoBorder","Input validation border color for information severity.")),u("inputValidation.warningBackground",{dark:"#352A05",light:"#F6F5D2",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputValidationWarningBackground","Input validation background color for warning severity.")),u("inputValidation.warningForeground",{dark:null,light:null,hcDark:null,hcLight:C},c.kg("inputValidationWarningForeground","Input validation foreground color for warning severity.")),u("inputValidation.warningBorder",{dark:"#B89500",light:"#B89500",hcDark:w,hcLight:w},c.kg("inputValidationWarningBorder","Input validation border color for warning severity.")),u("inputValidation.errorBackground",{dark:"#5A1D1D",light:"#F2DEDE",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputValidationErrorBackground","Input validation background color for error severity.")),u("inputValidation.errorForeground",{dark:null,light:null,hcDark:null,hcLight:C},c.kg("inputValidationErrorForeground","Input validation foreground color for error severity.")),u("inputValidation.errorBorder",{dark:"#BE1100",light:"#BE1100",hcDark:w,hcLight:w},c.kg("inputValidationErrorBorder","Input validation border color for error severity.")),u("dropdown.background",{dark:"#3C3C3C",light:s.Q1.white,hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("dropdownBackground","Dropdown background."))),fe=(u("dropdown.listBackground",{dark:null,light:null,hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("dropdownListBackground","Dropdown list background.")),u("dropdown.foreground",{dark:"#F0F0F0",light:C,hcDark:s.Q1.white,hcLight:C},c.kg("dropdownForeground","Dropdown foreground."))),me=u("dropdown.border",{dark:ge,light:"#CECECE",hcDark:w,hcLight:w},c.kg("dropdownBorder","Dropdown border.")),pe=u("button.foreground",s.Q1.white,c.kg("buttonForeground","Button foreground color.")),be=(u("button.separator",f(pe,.4),c.kg("buttonSeparator","Button separator color.")),u("button.background",{dark:"#0E639C",light:"#007ACC",hcDark:null,hcLight:"#0F4A85"},c.kg("buttonBackground","Button background color."))),_e=(u("button.hoverBackground",{dark:g(be,.2),light:d(be,.2),hcDark:be,hcLight:be},c.kg("buttonHoverBackground","Button background color when hovering.")),u("button.border",w,c.kg("buttonBorder","Button border color.")),u("button.secondaryForeground",{dark:s.Q1.white,light:s.Q1.white,hcDark:s.Q1.white,hcLight:C},c.kg("buttonSecondaryForeground","Secondary button foreground color.")),u("button.secondaryBackground",{dark:"#3A3D41",light:"#5F6A79",hcDark:null,hcLight:s.Q1.white},c.kg("buttonSecondaryBackground","Secondary button background color."))),ke=(u("button.secondaryHoverBackground",{dark:g(_e,.2),light:d(_e,.2),hcDark:null,hcLight:null},c.kg("buttonSecondaryHoverBackground","Secondary button background color when hovering.")),u("radio.activeForeground",de,c.kg("radioActiveForeground","Foreground color of active radio option."))),ve=(u("radio.activeBackground",ue,c.kg("radioBackground","Background color of active radio option.")),u("radio.activeBorder",ce,c.kg("radioActiveBorder","Border color of the active radio option.")),u("radio.inactiveForeground",null,c.kg("radioInactiveForeground","Foreground color of inactive radio option.")),u("radio.inactiveBackground",null,c.kg("radioInactiveBackground","Background color of inactive radio option.")),u("radio.inactiveBorder",{light:f(ke,.2),dark:f(ke,.2),hcDark:f(ke,.4),hcLight:f(ke,.2)},c.kg("radioInactiveBorder","Border color of the inactive radio option.")),u("radio.inactiveHoverBackground",he,c.kg("radioHoverBackground","Background color of inactive active radio option when hovering.")),u("checkbox.background",ge,c.kg("checkbox.background","Background color of checkbox widget.")),u("checkbox.selectBackground",O,c.kg("checkbox.select.background","Background color of checkbox widget when the element it's in is selected.")),u("checkbox.foreground",fe,c.kg("checkbox.foreground","Foreground color of checkbox widget.")),u("checkbox.border",me,c.kg("checkbox.border","Border color of checkbox widget.")),u("checkbox.selectBorder",y,c.kg("checkbox.select.border","Border color of checkbox widget when the element it's in is selected.")),u("keybindingLabel.background",{dark:new s.Q1(new s.bU(128,128,128,.17)),light:new s.Q1(new s.bU(221,221,221,.4)),hcDark:s.Q1.transparent,hcLight:s.Q1.transparent},c.kg("keybindingLabelBackground","Keybinding label background color. The keybinding label is used to represent a keyboard shortcut.")),u("keybindingLabel.foreground",{dark:s.Q1.fromHex("#CCCCCC"),light:s.Q1.fromHex("#555555"),hcDark:s.Q1.white,hcLight:C},c.kg("keybindingLabelForeground","Keybinding label foreground color. The keybinding label is used to represent a keyboard shortcut.")),u("keybindingLabel.border",{dark:new s.Q1(new s.bU(51,51,51,.6)),light:new s.Q1(new s.bU(204,204,204,.4)),hcDark:new s.Q1(new s.bU(111,195,223)),hcLight:w},c.kg("keybindingLabelBorder","Keybinding label border color. The keybinding label is used to represent a keyboard shortcut.")),u("keybindingLabel.bottomBorder",{dark:new s.Q1(new s.bU(68,68,68,.6)),light:new s.Q1(new s.bU(187,187,187,.4)),hcDark:new s.Q1(new s.bU(111,195,223)),hcLight:C},c.kg("keybindingLabelBottomBorder","Keybinding label border bottom color. The keybinding label is used to represent a keyboard shortcut.")),u("list.focusBackground",null,c.kg("listFocusBackground","List/Tree background color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),u("list.focusForeground",null,c.kg("listFocusForeground","List/Tree foreground color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),u("list.focusOutline",{dark:L,light:L,hcDark:S,hcLight:S},c.kg("listFocusOutline","List/Tree outline color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),u("list.focusAndSelectionOutline",null,c.kg("listFocusAndSelectionOutline","List/Tree outline color for the focused item when the list/tree is active and selected. An active list/tree has keyboard focus, an inactive does not.")),u("list.activeSelectionBackground",{dark:"#04395E",light:"#0060C0",hcDark:null,hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("listActiveSelectionBackground","List/Tree background color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not."))),Ce=u("list.activeSelectionForeground",{dark:s.Q1.white,light:s.Q1.white,hcDark:null,hcLight:null},c.kg("listActiveSelectionForeground","List/Tree foreground color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),ye=u("list.activeSelectionIconForeground",null,c.kg("listActiveSelectionIconForeground","List/Tree icon foreground color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),Le=(u("list.inactiveSelectionBackground",{dark:"#37373D",light:"#E4E6F1",hcDark:null,hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("listInactiveSelectionBackground","List/Tree background color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveSelectionForeground",null,c.kg("listInactiveSelectionForeground","List/Tree foreground color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveSelectionIconForeground",null,c.kg("listInactiveSelectionIconForeground","List/Tree icon foreground color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveFocusBackground",null,c.kg("listInactiveFocusBackground","List/Tree background color for the focused item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveFocusOutline",null,c.kg("listInactiveFocusOutline","List/Tree outline color for the focused item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.hoverBackground",{dark:"#2A2D2E",light:"#F0F0F0",hcDark:s.Q1.white.transparent(.1),hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("listHoverBackground","List/Tree background when hovering over items using the mouse.")),u("list.hoverForeground",null,c.kg("listHoverForeground","List/Tree foreground when hovering over items using the mouse.")),u("list.dropBackground",{dark:"#062F4A",light:"#D6EBFF",hcDark:null,hcLight:null},c.kg("listDropBackground","List/Tree drag and drop background when moving items over other items when using the mouse.")),u("list.dropBetweenBackground",{dark:y,light:y,hcDark:null,hcLight:null},c.kg("listDropBetweenBackground","List/Tree drag and drop border color when moving items between items when using the mouse.")),u("list.highlightForeground",{dark:"#2AAAFF",light:"#0066BF",hcDark:L,hcLight:L},c.kg("highlight","List/Tree foreground color of the match highlights when searching inside the list/tree.")));u("list.focusHighlightForeground",{dark:Le,light:(we=ve,Se=Le,xe="#BBE7FF",{op:6,if:we,then:Se,else:xe}),hcDark:Le,hcLight:Le},c.kg("listFocusHighlightForeground","List/Tree foreground color of the match highlights on actively focused items when searching inside the list/tree."));var we,Se,xe;u("list.invalidItemForeground",{dark:"#B89500",light:"#B89500",hcDark:"#B89500",hcLight:"#B5200D"},c.kg("invalidItemForeground","List/Tree foreground color for invalid items, for example an unresolved root in explorer.")),u("list.errorForeground",{dark:"#F88070",light:"#B01011",hcDark:null,hcLight:null},c.kg("listErrorForeground","Foreground color of list items containing errors.")),u("list.warningForeground",{dark:"#CCA700",light:"#855F00",hcDark:null,hcLight:null},c.kg("listWarningForeground","Foreground color of list items containing warnings.")),u("listFilterWidget.background",{light:d(O,0),dark:g(O,0),hcDark:O,hcLight:O},c.kg("listFilterWidgetBackground","Background color of the type filter widget in lists and trees.")),u("listFilterWidget.outline",{dark:s.Q1.transparent,light:s.Q1.transparent,hcDark:"#f38518",hcLight:"#007ACC"},c.kg("listFilterWidgetOutline","Outline color of the type filter widget in lists and trees.")),u("listFilterWidget.noMatchesOutline",{dark:"#BE1100",light:"#BE1100",hcDark:w,hcLight:w},c.kg("listFilterWidgetNoMatchesOutline","Outline color of the type filter widget in lists and trees, when there are no matches.")),u("listFilterWidget.shadow",J,c.kg("listFilterWidgetShadow","Shadow color of the type filter widget in lists and trees.")),u("list.filterMatchBackground",{dark:q,light:q,hcDark:null,hcLight:null},c.kg("listFilterMatchHighlight","Background color of the filtered match.")),u("list.filterMatchBorder",{dark:W,light:W,hcDark:w,hcLight:S},c.kg("listFilterMatchHighlightBorder","Border color of the filtered match.")),u("list.deemphasizedForeground",{dark:"#8C8C8C",light:"#8E8E90",hcDark:"#A7A8A9",hcLight:"#666666"},c.kg("listDeemphasizedForeground","List/Tree foreground color for items that are deemphasized."));const Ee=u("tree.indentGuidesStroke",{dark:"#585858",light:"#a9a9a9",hcDark:"#a9a9a9",hcLight:"#a5a5a5"},c.kg("treeIndentGuidesStroke","Tree stroke color for the indentation guides.")),Ne=(u("tree.inactiveIndentGuidesStroke",f(Ee,.4),c.kg("treeInactiveIndentGuidesStroke","Tree stroke color for the indentation guides that are not active.")),u("tree.tableColumnsBorder",{dark:"#CCCCCC20",light:"#61616120",hcDark:null,hcLight:null},c.kg("tableColumnsBorder","Table border color between columns.")),u("tree.tableOddRowsBackground",{dark:f(C,.04),light:f(C,.04),hcDark:null,hcLight:null},c.kg("tableOddRowsBackgroundColor","Background color for odd table rows.")),u("editorActionList.background",O,c.kg("editorActionListBackground","Action List background color.")),u("editorActionList.foreground",M,c.kg("editorActionListForeground","Action List foreground color.")),u("editorActionList.focusForeground",Ce,c.kg("editorActionListFocusForeground","Action List foreground color for the focused item.")),u("editorActionList.focusBackground",ve,c.kg("editorActionListFocusBackground","Action List background color for the focused item.")),u("menu.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("menuBorder","Border color of menus.")),u("menu.foreground",fe,c.kg("menuForeground","Foreground color of menu items.")),u("menu.background",ge,c.kg("menuBackground","Background color of menu items.")),u("menu.selectionForeground",Ce,c.kg("menuSelectionForeground","Foreground color of the selected menu item in menus.")),u("menu.selectionBackground",ve,c.kg("menuSelectionBackground","Background color of the selected menu item in menus.")),u("menu.selectionBorder",{dark:null,light:null,hcDark:S,hcLight:S},c.kg("menuSelectionBorder","Border color of the selected menu item in menus.")),u("menu.separatorBackground",{dark:"#606060",light:"#D4D4D4",hcDark:w,hcLight:w},c.kg("menuSeparatorBackground","Color of a separator menu item in menus.")),u("quickInput.background",O,c.kg("pickerBackground","Quick picker background color. The quick picker widget is the container for pickers like the command palette.")),u("quickInput.foreground",M,c.kg("pickerForeground","Quick picker foreground color. The quick picker widget is the container for pickers like the command palette.")),u("quickInputTitle.background",{dark:new s.Q1(new s.bU(255,255,255,.105)),light:new s.Q1(new s.bU(0,0,0,.06)),hcDark:"#000000",hcLight:s.Q1.white},c.kg("pickerTitleBackground","Quick picker title background color. The quick picker widget is the container for pickers like the command palette.")),u("pickerGroup.foreground",{dark:"#3794FF",light:"#0066BF",hcDark:s.Q1.white,hcLight:"#0F4A85"},c.kg("pickerGroupForeground","Quick picker color for grouping labels.")),u("pickerGroup.border",{dark:"#3F3F46",light:"#CCCEDB",hcDark:s.Q1.white,hcLight:"#0F4A85"},c.kg("pickerGroupBorder","Quick picker color for grouping borders.")),u("quickInput.list.focusBackground",null,"",void 0,c.kg("quickInput.list.focusBackground deprecation","Please use quickInputList.focusBackground instead")));u("quickInputList.focusForeground",Ce,c.kg("quickInput.listFocusForeground","Quick picker foreground color for the focused item.")),u("quickInputList.focusIconForeground",ye,c.kg("quickInput.listFocusIconForeground","Quick picker icon foreground color for the focused item.")),u("quickInputList.focusBackground",{dark:m(Ne,ve),light:m(Ne,ve),hcDark:null,hcLight:null},c.kg("quickInput.listFocusBackground","Quick picker background color for the focused item.")),u("search.resultsInfoForeground",{light:C,dark:f(C,.65),hcDark:C,hcLight:C},c.kg("search.resultsInfoForeground","Color of the text in the search viewlet's completion message.")),u("searchEditor.findMatchBackground",{light:f(q,.66),dark:f(q,.66),hcDark:q,hcLight:q},c.kg("searchEditor.queryMatch","Color of the Search Editor query matches.")),u("searchEditor.findMatchBorder",{light:f(W,.66),dark:f(W,.66),hcDark:W,hcLight:W},c.kg("searchEditor.editorFindMatchBorder","Border color of the Search Editor query matches."))},5724:(e,t,n)=>{"use strict";n.d(t,{Gy:()=>l,zy:()=>u,Yf:()=>c});var r,i=n(1234),s=n(1484),o=n(3591),a=n(6359);!function(e){e.DARK="dark",e.LIGHT="light",e.HIGH_CONTRAST_DARK="hcDark",e.HIGH_CONTRAST_LIGHT="hcLight"}(r||(r={}));const l=(0,o.u1)("themeService");function c(e){return{id:e}}const h=new class{constructor(){this.themingParticipants=[],this.themingParticipants=[],this.onThemingParticipantAddedEmitter=new i.vl}onColorThemeChange(e){return this.themingParticipants.push(e),this.onThemingParticipantAddedEmitter.fire(e),(0,s.s)((()=>{const t=this.themingParticipants.indexOf(e);this.themingParticipants.splice(t,1)}))}getThemingParticipants(){return this.themingParticipants}};function u(e){return h.onColorThemeChange(e)}a.O.add("base.contributions.theming",h);s.jG},5890:(e,t,n)=>{var r={"./simpleWorker":1929,"./simpleWorker.js":1929,"monaco-editor/esm/vs/base/common/worker/simpleWorker":1929,"monaco-editor/esm/vs/base/common/worker/simpleWorker.js":1929};function i(e){return Promise.resolve().then((()=>{if(!n.o(r,e)){var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}return n(r[e])}))}i.keys=()=>Object.keys(r),i.id=5890,e.exports=i},9204:(e,t,n)=>{var r={"./editorBaseApi":[4272],"./editorBaseApi.js":[4272],"./editorSimpleWorker":[5196],"./editorSimpleWorker.js":[5196],"./editorWorker":[920,792],"./editorWorker.js":[920,792],"./editorWorkerHost":[718],"./editorWorkerHost.js":[718],"./findSectionHeaders":[6691],"./findSectionHeaders.js":[6691],"./getIconClasses":[5628,792],"./getIconClasses.js":[5628,792],"./languageFeatureDebounce":[8709,792],"./languageFeatureDebounce.js":[8709,792],"./languageFeatures":[6942,792],"./languageFeatures.js":[6942,792],"./languageFeaturesService":[2661,792],"./languageFeaturesService.js":[2661,792],"./languageService":[7596,792],"./languageService.js":[7596,792],"./languagesAssociations":[9908,792],"./languagesAssociations.js":[9908,792],"./languagesRegistry":[9259,792],"./languagesRegistry.js":[9259,792],"./markerDecorations":[7550,792],"./markerDecorations.js":[7550,792],"./markerDecorationsService":[448,792],"./markerDecorationsService.js":[448,792],"./model":[3750,792],"./model.js":[3750,792],"./modelService":[1773,792],"./modelService.js":[1773,792],"./resolverService":[8938,792],"./resolverService.js":[8938,792],"./semanticTokensDto":[8232,792],"./semanticTokensDto.js":[8232,792],"./semanticTokensProviderStyling":[5538,792],"./semanticTokensProviderStyling.js":[5538,792],"./semanticTokensStyling":[4243,792],"./semanticTokensStyling.js":[4243,792],"./semanticTokensStylingService":[7004,792],"./semanticTokensStylingService.js":[7004,792],"./textModelSync/textModelSync.impl":[796],"./textModelSync/textModelSync.impl.js":[796],"./textModelSync/textModelSync.protocol":[8868,792],"./textModelSync/textModelSync.protocol.js":[8868,792],"./textResourceConfiguration":[360,792],"./textResourceConfiguration.js":[360,792],"./treeSitterParserService":[4432,792],"./treeSitterParserService.js":[4432,792],"./treeViewsDnd":[6723,792],"./treeViewsDnd.js":[6723,792],"./treeViewsDndService":[9100,792],"./treeViewsDndService.js":[9100,792],"./unicodeTextModelHighlighter":[4855],"./unicodeTextModelHighlighter.js":[4855],"monaco-editor/esm/vs/editor/common/services/editorBaseApi":[4272],"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":[4272],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":[5196],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":[5196],"monaco-editor/esm/vs/editor/common/services/editorWorker":[920,792],"monaco-editor/esm/vs/editor/common/services/editorWorker.js":[920,792],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":[718],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":[718],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":[6691],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":[6691],"monaco-editor/esm/vs/editor/common/services/getIconClasses":[5628,792],"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":[5628,792],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":[8709,792],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":[8709,792],"monaco-editor/esm/vs/editor/common/services/languageFeatures":[6942,792],"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":[6942,792],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":[2661,792],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":[2661,792],"monaco-editor/esm/vs/editor/common/services/languageService":[7596,792],"monaco-editor/esm/vs/editor/common/services/languageService.js":[7596,792],"monaco-editor/esm/vs/editor/common/services/languagesAssociations":[9908,792],"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":[9908,792],"monaco-editor/esm/vs/editor/common/services/languagesRegistry":[9259,792],"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":[9259,792],"monaco-editor/esm/vs/editor/common/services/markerDecorations":[7550,792],"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":[7550,792],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":[448,792],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":[448,792],"monaco-editor/esm/vs/editor/common/services/model":[3750,792],"monaco-editor/esm/vs/editor/common/services/model.js":[3750,792],"monaco-editor/esm/vs/editor/common/services/modelService":[1773,792],"monaco-editor/esm/vs/editor/common/services/modelService.js":[1773,792],"monaco-editor/esm/vs/editor/common/services/resolverService":[8938,792],"monaco-editor/esm/vs/editor/common/services/resolverService.js":[8938,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":[8232,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":[8232,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":[5538,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":[5538,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":[4243,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":[4243,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":[7004,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":[7004,792],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":[796],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":[796],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":[8868,792],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":[8868,792],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":[360,792],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":[360,792],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":[4432,792],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":[4432,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":[6723,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":[6723,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":[9100,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":[9100,792],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":[4855],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":[4855]};function i(e){if(!n.o(r,e))return Promise.resolve().then((()=>{var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}));var t=r[e],i=t[0];return Promise.all(t.slice(1).map(n.e)).then((()=>n(i)))}i.keys=()=>Object.keys(r),i.id=9204,e.exports=i},7614:(e,t,n)=>{var r={"./editorBaseApi":4272,"./editorBaseApi.js":4272,"./editorSimpleWorker":5196,"./editorSimpleWorker.js":5196,"./editorWorker":920,"./editorWorker.js":920,"./editorWorkerHost":718,"./editorWorkerHost.js":718,"./findSectionHeaders":6691,"./findSectionHeaders.js":6691,"./getIconClasses":5628,"./getIconClasses.js":5628,"./languageFeatureDebounce":8709,"./languageFeatureDebounce.js":8709,"./languageFeatures":6942,"./languageFeatures.js":6942,"./languageFeaturesService":2661,"./languageFeaturesService.js":2661,"./languageService":7596,"./languageService.js":7596,"./languagesAssociations":9908,"./languagesAssociations.js":9908,"./languagesRegistry":9259,"./languagesRegistry.js":9259,"./markerDecorations":7550,"./markerDecorations.js":7550,"./markerDecorationsService":448,"./markerDecorationsService.js":448,"./model":3750,"./model.js":3750,"./modelService":1773,"./modelService.js":1773,"./resolverService":8938,"./resolverService.js":8938,"./semanticTokensDto":8232,"./semanticTokensDto.js":8232,"./semanticTokensProviderStyling":5538,"./semanticTokensProviderStyling.js":5538,"./semanticTokensStyling":4243,"./semanticTokensStyling.js":4243,"./semanticTokensStylingService":7004,"./semanticTokensStylingService.js":7004,"./textModelSync/textModelSync.impl":796,"./textModelSync/textModelSync.impl.js":796,"./textModelSync/textModelSync.protocol":8868,"./textModelSync/textModelSync.protocol.js":8868,"./textResourceConfiguration":360,"./textResourceConfiguration.js":360,"./treeSitterParserService":4432,"./treeSitterParserService.js":4432,"./treeViewsDnd":6723,"./treeViewsDnd.js":6723,"./treeViewsDndService":9100,"./treeViewsDndService.js":9100,"./unicodeTextModelHighlighter":4855,"./unicodeTextModelHighlighter.js":4855,"monaco-editor/esm/vs/editor/common/services/editorBaseApi":4272,"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":4272,"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":5196,"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":5196,"monaco-editor/esm/vs/editor/common/services/editorWorker":920,"monaco-editor/esm/vs/editor/common/services/editorWorker.js":920,"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":718,"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":718,"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":6691,"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":6691,"monaco-editor/esm/vs/editor/common/services/getIconClasses":5628,"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":5628,"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":8709,"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":8709,"monaco-editor/esm/vs/editor/common/services/languageFeatures":6942,"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":6942,"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":2661,"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":2661,"monaco-editor/esm/vs/editor/common/services/languageService":7596,"monaco-editor/esm/vs/editor/common/services/languageService.js":7596,"monaco-editor/esm/vs/editor/common/services/languagesAssociations":9908,"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":9908,"monaco-editor/esm/vs/editor/common/services/languagesRegistry":9259,"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":9259,"monaco-editor/esm/vs/editor/common/services/markerDecorations":7550,"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":7550,"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":448,"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":448,"monaco-editor/esm/vs/editor/common/services/model":3750,"monaco-editor/esm/vs/editor/common/services/model.js":3750,"monaco-editor/esm/vs/editor/common/services/modelService":1773,"monaco-editor/esm/vs/editor/common/services/modelService.js":1773,"monaco-editor/esm/vs/editor/common/services/resolverService":8938,"monaco-editor/esm/vs/editor/common/services/resolverService.js":8938,"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":8232,"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":8232,"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":5538,"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":5538,"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":4243,"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":4243,"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":7004,"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":7004,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":796,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":796,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":8868,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":8868,"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":360,"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":360,"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":4432,"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":4432,"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":6723,"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":6723,"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":9100,"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":9100,"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":4855,"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":4855};function i(e){var t=s(e);return n(t)}function s(e){if(!n.o(r,e)){var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}return r[e]}i.keys=function(){return Object.keys(r)},i.resolve=s,e.exports=i,i.id=7614}},t={};function n(r){var i=t[r];if(void 0!==i)return i.exports;var s=t[r]={exports:{}};return e[r](s,s.exports,n),s.exports}n.d=(e,t)=>{for(var r in t)n.o(t,r)&&!n.o(e,r)&&Object.defineProperty(e,r,{enumerable:!0,get:t[r]})},n.e=()=>Promise.resolve(),n.o=(e,t)=>Object.prototype.hasOwnProperty.call(e,t),n.r=e=>{"undefined"!==typeof Symbol&&Symbol.toStringTag&&Object.defineProperty(e,Symbol.toStringTag,{value:"Module"}),Object.defineProperty(e,"__esModule",{value:!0})},(()=>{"use strict";var e=n(1929),t=n(5196),r=n(718);let i=!1;function s(n){if(i)return;i=!0;const s=new e.SimpleWorkerServer((e=>{globalThis.postMessage(e)}),(e=>new t.EditorSimpleWorker(r.EditorWorkerHost.getChannel(e),n)));globalThis.onmessage=e=>{s.onmessage(e.data)}}function o(e,t=!1){const n=e.length;let r=0,i="",s=0,o=16,h=0,u=0,d=0,g=0,f=0;function m(t,n){let i=0,s=0;for(;i=48&&t<=57)s=16*s+t-48;else if(t>=65&&t<=70)s=16*s+t-65+10;else{if(!(t>=97&&t<=102))break;s=16*s+t-97+10}r++,i++}return i=n)return s=n,o=17;let t=e.charCodeAt(r);if(a(t)){do{r++,i+=String.fromCharCode(t),t=e.charCodeAt(r)}while(a(t));return o=15}if(l(t))return r++,i+=String.fromCharCode(t),13===t&&10===e.charCodeAt(r)&&(r++,i+="\n"),h++,d=r,o=14;switch(t){case 123:return r++,o=1;case 125:return r++,o=2;case 91:return r++,o=3;case 93:return r++,o=4;case 58:return r++,o=6;case 44:return r++,o=5;case 34:return r++,i=function(){let t="",i=r;for(;;){if(r>=n){t+=e.substring(i,r),f=2;break}const s=e.charCodeAt(r);if(34===s){t+=e.substring(i,r),r++;break}if(92!==s){if(s>=0&&s<=31){if(l(s)){t+=e.substring(i,r),f=2;break}f=6}r++}else{if(t+=e.substring(i,r),r++,r>=n){f=2;break}switch(e.charCodeAt(r++)){case 34:t+='"';break;case 92:t+="\\";break;case 47:t+="/";break;case 98:t+="\b";break;case 102:t+="\f";break;case 110:t+="\n";break;case 114:t+="\r";break;case 116:t+="\t";break;case 117:const e=m(4,!0);e>=0?t+=String.fromCharCode(e):f=4;break;default:f=5}i=r}}return t}(),o=10;case 47:const a=r-1;if(47===e.charCodeAt(r+1)){for(r+=2;rr,scan:t?function(){let e;do{e=p()}while(e>=12&&e<=15);return e}:p,getToken:()=>o,getTokenValue:()=>i,getTokenOffset:()=>s,getTokenLength:()=>r-s,getTokenStartLine:()=>u,getTokenStartCharacter:()=>s-g,getTokenError:()=>f}}function a(e){return 32===e||9===e}function l(e){return 10===e||13===e}function c(e){return e>=48&&e<=57}var h,u;globalThis.onmessage=e=>{i||s(null)},(u=h||(h={}))[u.lineFeed=10]="lineFeed",u[u.carriageReturn=13]="carriageReturn",u[u.space=32]="space",u[u._0=48]="_0",u[u._1=49]="_1",u[u._2=50]="_2",u[u._3=51]="_3",u[u._4=52]="_4",u[u._5=53]="_5",u[u._6=54]="_6",u[u._7=55]="_7",u[u._8=56]="_8",u[u._9=57]="_9",u[u.a=97]="a",u[u.b=98]="b",u[u.c=99]="c",u[u.d=100]="d",u[u.e=101]="e",u[u.f=102]="f",u[u.g=103]="g",u[u.h=104]="h",u[u.i=105]="i",u[u.j=106]="j",u[u.k=107]="k",u[u.l=108]="l",u[u.m=109]="m",u[u.n=110]="n",u[u.o=111]="o",u[u.p=112]="p",u[u.q=113]="q",u[u.r=114]="r",u[u.s=115]="s",u[u.t=116]="t",u[u.u=117]="u",u[u.v=118]="v",u[u.w=119]="w",u[u.x=120]="x",u[u.y=121]="y",u[u.z=122]="z",u[u.A=65]="A",u[u.B=66]="B",u[u.C=67]="C",u[u.D=68]="D",u[u.E=69]="E",u[u.F=70]="F",u[u.G=71]="G",u[u.H=72]="H",u[u.I=73]="I",u[u.J=74]="J",u[u.K=75]="K",u[u.L=76]="L",u[u.M=77]="M",u[u.N=78]="N",u[u.O=79]="O",u[u.P=80]="P",u[u.Q=81]="Q",u[u.R=82]="R",u[u.S=83]="S",u[u.T=84]="T",u[u.U=85]="U",u[u.V=86]="V",u[u.W=87]="W",u[u.X=88]="X",u[u.Y=89]="Y",u[u.Z=90]="Z",u[u.asterisk=42]="asterisk",u[u.backslash=92]="backslash",u[u.closeBrace=125]="closeBrace",u[u.closeBracket=93]="closeBracket",u[u.colon=58]="colon",u[u.comma=44]="comma",u[u.dot=46]="dot",u[u.doubleQuote=34]="doubleQuote",u[u.minus=45]="minus",u[u.openBrace=123]="openBrace",u[u.openBracket=91]="openBracket",u[u.plus=43]="plus",u[u.slash=47]="slash",u[u.formFeed=12]="formFeed",u[u.tab=9]="tab";var d,g=new Array(20).fill(0).map(((e,t)=>" ".repeat(t))),f=200,m={" ":{"\n":new Array(f).fill(0).map(((e,t)=>"\n"+" ".repeat(t))),"\r":new Array(f).fill(0).map(((e,t)=>"\r"+" ".repeat(t))),"\r\n":new Array(f).fill(0).map(((e,t)=>"\r\n"+" ".repeat(t)))},"\t":{"\n":new Array(f).fill(0).map(((e,t)=>"\n"+"\t".repeat(t))),"\r":new Array(f).fill(0).map(((e,t)=>"\r"+"\t".repeat(t))),"\r\n":new Array(f).fill(0).map(((e,t)=>"\r\n"+"\t".repeat(t)))}},p=["\n","\r","\r\n"];function b(e,t,n){let r,i,s,a,l;if(t){for(a=t.offset,l=a+t.length,s=a;s>0&&!k(e,s-1);)s--;let o=l;for(;o1)return _(c,d)+_(u,r+f);const e=u.length*(r+f);return!h||e>m[b][c].length?c+_(u,r+f):e<=0?c:m[b][c][e]}function L(){let e=v.scan();for(d=0;15===e||14===e;)14===e&&n.keepLines?d+=1:14===e&&(d=1),e=v.scan();return C=16===e||0!==v.getTokenError(),e}const w=[];function S(n,r,i){C||t&&!(ra)||e.substring(r,i)===n||w.push({offset:r,length:i-r,content:n})}let x=L();if(n.keepLines&&d>0&&S(_(c,d),0,0),17!==x){let e=v.getTokenOffset()+s;S(u.length*r<20&&n.insertSpaces?g[u.length*r]:_(u,r),s,e)}for(;17!==x;){let e=v.getTokenOffset()+v.getTokenLength()+s,t=L(),r="",i=!1;for(;0===d&&(12===t||13===t);){let n=v.getTokenOffset()+s;S(g[1],e,n),e=v.getTokenOffset()+v.getTokenLength()+s,i=12===t,r=i?y():"",t=L()}if(2===t)1!==x&&f--,n.keepLines&&d>0||!n.keepLines&&1!==x?r=y():n.keepLines&&(r=g[1]);else if(4===t)3!==x&&f--,n.keepLines&&d>0||!n.keepLines&&3!==x?r=y():n.keepLines&&(r=g[1]);else{switch(x){case 3:case 1:f++,r=n.keepLines&&d>0||!n.keepLines?y():g[1];break;case 5:r=n.keepLines&&d>0||!n.keepLines?y():g[1];break;case 12:r=y();break;case 13:d>0?r=y():i||(r=g[1]);break;case 6:n.keepLines&&d>0?r=y():i||(r=g[1]);break;case 10:n.keepLines&&d>0?r=y():6!==t||i||(r="");break;case 7:case 8:case 9:case 11:case 2:case 4:n.keepLines&&d>0?r=y():12!==t&&13!==t||i?5!==t&&17!==t&&(C=!0):r=g[1];break;case 16:C=!0}d>0&&(12===t||13===t)&&(r=y())}17===t&&(r=n.keepLines&&d>0?y():n.insertFinalNewline?c:"");S(r,e,v.getTokenOffset()+s),x=t}return w}function _(e,t){let n="";for(let r=0;re(r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter()):()=>!0}function a(e){return e?()=>e(r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter(),(()=>i.slice())):()=>!0}function l(e){return e?t=>e(t,r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter()):()=>!0}function c(e){return e?t=>e(t,r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter(),(()=>i.slice())):()=>!0}const h=a(t.onObjectBegin),u=c(t.onObjectProperty),g=s(t.onObjectEnd),f=a(t.onArrayBegin),m=s(t.onArrayEnd),p=c(t.onLiteralValue),b=l(t.onSeparator),_=s(t.onComment),k=l(t.onError),v=n&&n.disallowComments,C=n&&n.allowTrailingComma;function y(){for(;;){const e=r.scan();switch(r.getTokenError()){case 4:L(14);break;case 5:L(15);break;case 3:L(13);break;case 1:v||L(11);break;case 2:L(12);break;case 6:L(16)}switch(e){case 12:case 13:v?L(10):_();break;case 16:L(1);break;case 15:case 14:break;default:return e}}}function L(e,t=[],n=[]){if(k(e),t.length+n.length>0){let e=r.getToken();for(;17!==e;){if(-1!==t.indexOf(e)){y();break}if(-1!==n.indexOf(e))break;e=y()}}}function w(e){const t=r.getTokenValue();return e?p(t):(u(t),i.push(t)),y(),!0}function S(){switch(r.getToken()){case 11:const e=r.getTokenValue();let t=Number(e);isNaN(t)&&(L(2),t=0),p(t);break;case 7:p(null);break;case 8:p(!0);break;case 9:p(!1);break;default:return!1}return y(),!0}function x(){return 10!==r.getToken()?(L(3,[],[2,5]),!1):(w(!1),6===r.getToken()?(b(":"),y(),T()||L(4,[],[2,5])):L(5,[],[2,5]),i.pop(),!0)}function E(){h(),y();let e=!1;for(;2!==r.getToken()&&17!==r.getToken();){if(5===r.getToken()){if(e||L(4,[],[]),b(","),y(),2===r.getToken()&&C)break}else e&&L(6,[],[]);x()||L(4,[],[2,5]),e=!0}return g(),2!==r.getToken()?L(7,[2],[]):y(),!0}function N(){f(),y();let e=!0,t=!1;for(;4!==r.getToken()&&17!==r.getToken();){if(5===r.getToken()){if(t||L(4,[],[]),b(","),y(),4===r.getToken()&&C)break}else t&&L(6,[],[]);e?(i.push(0),e=!1):i[i.length-1]++,T()||L(4,[],[4,5]),t=!0}return m(),e||i.pop(),4!==r.getToken()?L(8,[4],[]):y(),!0}function T(){switch(r.getToken()){case 3:return N();case 1:return E();case 10:return w(!0);default:return S()}}if(y(),17===r.getToken())return!!n.allowEmptyContent||(L(4,[],[]),!1);if(!T())return L(4,[],[]),!1;17!==r.getToken()&&L(9,[],[])}(e,{onObjectBegin:()=>{const e={};a(e),s.push(i),i=e,r=null},onObjectProperty:e=>{r=e},onObjectEnd:()=>{i=s.pop()},onArrayBegin:()=>{const e=[];a(e),s.push(i),i=e,r=null},onArrayEnd:()=>{i=s.pop()},onLiteralValue:a,onError:(e,n,r)=>{t.push({error:e,offset:n,length:r})}},n),i[0]},Zt=function e(t,n,r=!1){if(function(e,t,n=!1){return t>=e.offset&&t0?e.lastIndexOf(t)===n:0===n&&e===t}function hn(e){let t="";(function(e,t){if(e.length0&&(r.arguments=n),r},ae.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.title)&&dn.string(t.command)},(ce=le||(le={})).replace=function(e,t){return{range:e,newText:t}},ce.insert=function(e,t){return{range:{start:e,end:e},newText:t}},ce.del=function(e){return{range:e,newText:""}},ce.is=function(e){const t=e;return dn.objectLiteral(t)&&dn.string(t.newText)&&D.is(t.range)},(ue=he||(he={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},ue.is=function(e){const t=e;return dn.objectLiteral(t)&&dn.string(t.label)&&(dn.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(dn.string(t.description)||void 0===t.description)},(de||(de={})).is=function(e){const t=e;return dn.string(t)},(fe=ge||(ge={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},fe.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},fe.del=function(e,t){return{range:e,newText:"",annotationId:t}},fe.is=function(e){const t=e;return le.is(t)&&(he.is(t.annotationId)||de.is(t.annotationId))},(pe=me||(me={})).create=function(e,t){return{textDocument:e,edits:t}},pe.is=function(e){let t=e;return dn.defined(t)&&Ne.is(t.textDocument)&&Array.isArray(t.edits)},(_e=be||(be={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},_e.is=function(e){let t=e;return t&&"create"===t.kind&&dn.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||dn.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||dn.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||de.is(t.annotationId))},(ve=ke||(ke={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},ve.is=function(e){let t=e;return t&&"rename"===t.kind&&dn.string(t.oldUri)&&dn.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||dn.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||dn.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||de.is(t.annotationId))},(ye=Ce||(Ce={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},ye.is=function(e){let t=e;return t&&"delete"===t.kind&&dn.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||dn.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||dn.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||de.is(t.annotationId))},(Le||(Le={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>dn.string(e.kind)?be.is(e)||ke.is(e)||Ce.is(e):me.is(e))))},(Se=we||(we={})).create=function(e){return{uri:e}},Se.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)},(Ee=xe||(xe={})).create=function(e,t){return{uri:e,version:t}},Ee.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)&&dn.integer(t.version)},(Te=Ne||(Ne={})).create=function(e,t){return{uri:e,version:t}},Te.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)&&(null===t.version||dn.integer(t.version))},(Ie=Ae||(Ae={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},Ie.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)&&dn.string(t.languageId)&&dn.integer(t.version)&&dn.string(t.text)},(Me=Oe||(Oe={})).PlainText="plaintext",Me.Markdown="markdown",Me.is=function(e){const t=e;return t===Me.PlainText||t===Me.Markdown},(Re||(Re={})).is=function(e){const t=e;return dn.objectLiteral(e)&&Oe.is(t.kind)&&dn.string(t.value)},(Be=De||(De={})).Text=1,Be.Method=2,Be.Function=3,Be.Constructor=4,Be.Field=5,Be.Variable=6,Be.Class=7,Be.Interface=8,Be.Module=9,Be.Property=10,Be.Unit=11,Be.Value=12,Be.Enum=13,Be.Keyword=14,Be.Snippet=15,Be.Color=16,Be.File=17,Be.Reference=18,Be.Folder=19,Be.EnumMember=20,Be.Constant=21,Be.Struct=22,Be.Event=23,Be.Operator=24,Be.TypeParameter=25,(Pe=Fe||(Fe={})).PlainText=1,Pe.Snippet=2,(Ve||(Ve={})).Deprecated=1,(je=ze||(ze={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},je.is=function(e){const t=e;return t&&dn.string(t.newText)&&D.is(t.insert)&&D.is(t.replace)},(We=qe||(qe={})).asIs=1,We.adjustIndentation=2,(Ue||(Ue={})).is=function(e){const t=e;return t&&(dn.string(t.detail)||void 0===t.detail)&&(dn.string(t.description)||void 0===t.description)},($e||($e={})).create=function(e){return{label:e}},(He||(He={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(Ge=Ke||(Ke={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},Ge.is=function(e){const t=e;return dn.string(t)||dn.objectLiteral(t)&&dn.string(t.language)&&dn.string(t.value)},(Qe||(Qe={})).is=function(e){let t=e;return!!t&&dn.objectLiteral(t)&&(Re.is(t.contents)||Ke.is(t.contents)||dn.typedArray(t.contents,Ke.is))&&(void 0===e.range||D.is(e.range))},(Je||(Je={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(Xe||(Xe={})).create=function(e,t,...n){let r={label:e};return dn.defined(t)&&(r.documentation=t),dn.defined(n)?r.parameters=n:r.parameters=[],r},(Ze=Ye||(Ye={})).Text=1,Ze.Read=2,Ze.Write=3,(et||(et={})).create=function(e,t){let n={range:e};return dn.number(t)&&(n.kind=t),n},(nt=tt||(tt={})).File=1,nt.Module=2,nt.Namespace=3,nt.Package=4,nt.Class=5,nt.Method=6,nt.Property=7,nt.Field=8,nt.Constructor=9,nt.Enum=10,nt.Interface=11,nt.Function=12,nt.Variable=13,nt.Constant=14,nt.String=15,nt.Number=16,nt.Boolean=17,nt.Array=18,nt.Object=19,nt.Key=20,nt.Null=21,nt.EnumMember=22,nt.Struct=23,nt.Event=24,nt.Operator=25,nt.TypeParameter=26,(rt||(rt={})).Deprecated=1,(it||(it={})).create=function(e,t,n,r,i){let s={name:e,kind:t,location:{uri:r,range:n}};return i&&(s.containerName=i),s},(st||(st={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},(at=ot||(ot={})).create=function(e,t,n,r,i,s){let o={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==s&&(o.children=s),o},at.is=function(e){let t=e;return t&&dn.string(t.name)&&dn.number(t.kind)&&D.is(t.range)&&D.is(t.selectionRange)&&(void 0===t.detail||dn.string(t.detail))&&(void 0===t.deprecated||dn.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},(ct=lt||(lt={})).Empty="",ct.QuickFix="quickfix",ct.Refactor="refactor",ct.RefactorExtract="refactor.extract",ct.RefactorInline="refactor.inline",ct.RefactorRewrite="refactor.rewrite",ct.Source="source",ct.SourceOrganizeImports="source.organizeImports",ct.SourceFixAll="source.fixAll",(ut=ht||(ht={})).Invoked=1,ut.Automatic=2,(gt=dt||(dt={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},gt.is=function(e){let t=e;return dn.defined(t)&&dn.typedArray(t.diagnostics,ie.is)&&(void 0===t.only||dn.typedArray(t.only,dn.string))&&(void 0===t.triggerKind||t.triggerKind===ht.Invoked||t.triggerKind===ht.Automatic)},(mt=ft||(ft={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):oe.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},mt.is=function(e){let t=e;return t&&dn.string(t.title)&&(void 0===t.diagnostics||dn.typedArray(t.diagnostics,ie.is))&&(void 0===t.kind||dn.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||oe.is(t.command))&&(void 0===t.isPreferred||dn.boolean(t.isPreferred))&&(void 0===t.edit||Le.is(t.edit))},(bt=pt||(pt={})).create=function(e,t){let n={range:e};return dn.defined(t)&&(n.data=t),n},bt.is=function(e){let t=e;return dn.defined(t)&&D.is(t.range)&&(dn.undefined(t.command)||oe.is(t.command))},(kt=_t||(_t={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},kt.is=function(e){let t=e;return dn.defined(t)&&dn.uinteger(t.tabSize)&&dn.boolean(t.insertSpaces)},(Ct=vt||(vt={})).create=function(e,t,n){return{range:e,target:t,data:n}},Ct.is=function(e){let t=e;return dn.defined(t)&&D.is(t.range)&&(dn.undefined(t.target)||dn.string(t.target))},(Lt=yt||(yt={})).create=function(e,t){return{range:e,parent:t}},Lt.is=function(e){let t=e;return dn.objectLiteral(t)&&D.is(t.range)&&(void 0===t.parent||Lt.is(t.parent))},(St=wt||(wt={})).namespace="namespace",St.type="type",St.class="class",St.enum="enum",St.interface="interface",St.struct="struct",St.typeParameter="typeParameter",St.parameter="parameter",St.variable="variable",St.property="property",St.enumMember="enumMember",St.event="event",St.function="function",St.method="method",St.macro="macro",St.keyword="keyword",St.modifier="modifier",St.comment="comment",St.string="string",St.number="number",St.regexp="regexp",St.operator="operator",St.decorator="decorator",(Et=xt||(xt={})).declaration="declaration",Et.definition="definition",Et.readonly="readonly",Et.static="static",Et.deprecated="deprecated",Et.abstract="abstract",Et.async="async",Et.modification="modification",Et.documentation="documentation",Et.defaultLibrary="defaultLibrary",(Nt||(Nt={})).is=function(e){const t=e;return dn.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(At=Tt||(Tt={})).create=function(e,t){return{range:e,text:t}},At.is=function(e){const t=e;return void 0!==t&&null!==t&&D.is(t.range)&&dn.string(t.text)},(Ot=It||(It={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},Ot.is=function(e){const t=e;return void 0!==t&&null!==t&&D.is(t.range)&&dn.boolean(t.caseSensitiveLookup)&&(dn.string(t.variableName)||void 0===t.variableName)},(Rt=Mt||(Mt={})).create=function(e,t){return{range:e,expression:t}},Rt.is=function(e){const t=e;return void 0!==t&&null!==t&&D.is(t.range)&&(dn.string(t.expression)||void 0===t.expression)},(Bt=Dt||(Dt={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},Bt.is=function(e){const t=e;return dn.defined(t)&&D.is(e.stoppedLocation)},(Pt=Ft||(Ft={})).Type=1,Pt.Parameter=2,Pt.is=function(e){return 1===e||2===e},(zt=Vt||(Vt={})).create=function(e){return{value:e}},zt.is=function(e){const t=e;return dn.objectLiteral(t)&&(void 0===t.tooltip||dn.string(t.tooltip)||Re.is(t.tooltip))&&(void 0===t.location||F.is(t.location))&&(void 0===t.command||oe.is(t.command))},(qt=jt||(jt={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},qt.is=function(e){const t=e;return dn.objectLiteral(t)&&M.is(t.position)&&(dn.string(t.label)||dn.typedArray(t.label,Vt.is))&&(void 0===t.kind||Ft.is(t.kind))&&void 0===t.textEdits||dn.typedArray(t.textEdits,le.is)&&(void 0===t.tooltip||dn.string(t.tooltip)||Re.is(t.tooltip))&&(void 0===t.paddingLeft||dn.boolean(t.paddingLeft))&&(void 0===t.paddingRight||dn.boolean(t.paddingRight))},(Wt||(Wt={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Ut||(Ut={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},($t||($t={})).create=function(e){return{items:e}},(Kt=Ht||(Ht={})).Invoked=0,Kt.Automatic=1,(Gt||(Gt={})).create=function(e,t){return{range:e,text:t}},(Qt||(Qt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(Jt||(Jt={})).is=function(e){const t=e;return dn.objectLiteral(t)&&N.is(t.uri)&&dn.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),s=e.slice(r);t(i,n),t(s,n);let o=0,a=0,l=0;for(;o{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),s=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],o=e.offsetAt(n.range.start),a=e.offsetAt(n.range.end);if(!(a<=s))throw new Error("Overlapping edit");r=r.substring(0,o)+n.newText+r.substring(a,r.length),s=o}return r}}(Xt||(Xt={}));var dn,gn=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return M.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return M.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1e?r=i:n=i+1}let i=n-1;return{line:i,character:e-t[i]}}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1n.line||t.line===n.line&&t.character>n.character?{start:n,end:t}:e}function Sn(e){const t=wn(e.range);return t!==e.range?{newText:e.newText,range:t}:e}function xn(...e){const t=e[0];let n,r,i;if("string"===typeof t)n=t,r=t,e.splice(0,1),i=e&&"object"===typeof e[0]?e[0]:e;else{if(t instanceof Array){const n=e.slice(1);if(t.length!==n.length+1)throw new Error("expected a string as the first argument to l10n.t");let r=t[0];for(let e=1;e0&&(n+=`/${Array.isArray(t.comment)?t.comment.join(""):t.comment}`),i=t.args??{}}return Nn(r,i)}(mn=fn||(fn={})).create=function(e,t,n,r){return new Cn(e,t,n,r)},mn.update=function(e,t,n){if(e instanceof Cn)return e.update(t,n),e;throw new Error("TextDocument.update: document must be created by TextDocument.create")},mn.applyEdits=function(e,t){let n=e.getText(),r=yn(t.map(Sn),((e,t)=>{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),i=0;const s=[];for(const o of r){let t=e.offsetAt(o.range.start);if(ti&&s.push(n.substring(i,t)),o.newText.length&&s.push(o.newText),i=e.offsetAt(o.range.end)}return s.push(n.substr(i)),s.join("")},(bn=pn||(pn={}))[bn.Undefined=0]="Undefined",bn[bn.EnumValueMismatch=1]="EnumValueMismatch",bn[bn.Deprecated=2]="Deprecated",bn[bn.UnexpectedEndOfComment=257]="UnexpectedEndOfComment",bn[bn.UnexpectedEndOfString=258]="UnexpectedEndOfString",bn[bn.UnexpectedEndOfNumber=259]="UnexpectedEndOfNumber",bn[bn.InvalidUnicode=260]="InvalidUnicode",bn[bn.InvalidEscapeCharacter=261]="InvalidEscapeCharacter",bn[bn.InvalidCharacter=262]="InvalidCharacter",bn[bn.PropertyExpected=513]="PropertyExpected",bn[bn.CommaExpected=514]="CommaExpected",bn[bn.ColonExpected=515]="ColonExpected",bn[bn.ValueExpected=516]="ValueExpected",bn[bn.CommaOrCloseBacketExpected=517]="CommaOrCloseBacketExpected",bn[bn.CommaOrCloseBraceExpected=518]="CommaOrCloseBraceExpected",bn[bn.TrailingComma=519]="TrailingComma",bn[bn.DuplicateKey=520]="DuplicateKey",bn[bn.CommentNotPermitted=521]="CommentNotPermitted",bn[bn.PropertyKeysMustBeDoublequoted=528]="PropertyKeysMustBeDoublequoted",bn[bn.SchemaResolveError=768]="SchemaResolveError",bn[bn.SchemaUnsupportedFeature=769]="SchemaUnsupportedFeature",(kn=_n||(_n={}))[kn.v3=3]="v3",kn[kn.v4=4]="v4",kn[kn.v6=6]="v6",kn[kn.v7=7]="v7",kn[kn.v2019_09=19]="v2019_09",kn[kn.v2020_12=20]="v2020_12",(vn||(vn={})).LATEST={textDocument:{completion:{completionItem:{documentationFormat:[Oe.Markdown,Oe.PlainText],commitCharactersSupport:!0,labelDetailsSupport:!0}}}};var En=/{([^}]+)}/g;function Nn(e,t){return 0===Object.keys(t).length?e:e.replace(En,((e,n)=>t[n]??e))}var Tn,An,In={"color-hex":{errorMessage:xn("Invalid color format. Use #RGB, #RGBA, #RRGGBB or #RRGGBBAA."),pattern:/^#([0-9A-Fa-f]{3,4}|([0-9A-Fa-f]{2}){3,4})$/},"date-time":{errorMessage:xn("String is not a RFC3339 date-time."),pattern:/^(\d{4})-(0[1-9]|1[0-2])-(0[1-9]|[12][0-9]|3[01])T([01][0-9]|2[0-3]):([0-5][0-9]):([0-5][0-9]|60)(\.[0-9]+)?(Z|(\+|-)([01][0-9]|2[0-3]):([0-5][0-9]))$/i},date:{errorMessage:xn("String is not a RFC3339 date."),pattern:/^(\d{4})-(0[1-9]|1[0-2])-(0[1-9]|[12][0-9]|3[01])$/i},time:{errorMessage:xn("String is not a RFC3339 time."),pattern:/^([01][0-9]|2[0-3]):([0-5][0-9]):([0-5][0-9]|60)(\.[0-9]+)?(Z|(\+|-)([01][0-9]|2[0-3]):([0-5][0-9]))$/i},email:{errorMessage:xn("String is not an e-mail address."),pattern:/^(([^<>()\[\]\\.,;:\s@"]+(\.[^<>()\[\]\\.,;:\s@"]+)*)|(".+"))@((\[[0-9]{1,3}\.[0-9]{1,3}\.[0-9]{1,3}\.[0-9]{1,3}])|(([a-zA-Z0-9-]+\.)+[a-zA-Z]{2,}))$/},hostname:{errorMessage:xn("String is not a hostname."),pattern:/^(?=.{1,253}\.?$)[a-z0-9](?:[a-z0-9-]{0,61}[a-z0-9])?(?:\.[a-z0-9](?:[-0-9a-z]{0,61}[0-9a-z])?)*\.?$/i},ipv4:{errorMessage:xn("String is not an IPv4 address."),pattern:/^(?:(?:25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)\.){3}(?:25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)$/},ipv6:{errorMessage:xn("String is not an IPv6 address."),pattern:/^((([0-9a-f]{1,4}:){7}([0-9a-f]{1,4}|:))|(([0-9a-f]{1,4}:){6}(:[0-9a-f]{1,4}|((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3})|:))|(([0-9a-f]{1,4}:){5}(((:[0-9a-f]{1,4}){1,2})|:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3})|:))|(([0-9a-f]{1,4}:){4}(((:[0-9a-f]{1,4}){1,3})|((:[0-9a-f]{1,4})?:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(([0-9a-f]{1,4}:){3}(((:[0-9a-f]{1,4}){1,4})|((:[0-9a-f]{1,4}){0,2}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(([0-9a-f]{1,4}:){2}(((:[0-9a-f]{1,4}){1,5})|((:[0-9a-f]{1,4}){0,3}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(([0-9a-f]{1,4}:){1}(((:[0-9a-f]{1,4}){1,6})|((:[0-9a-f]{1,4}){0,4}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(:(((:[0-9a-f]{1,4}){1,7})|((:[0-9a-f]{1,4}){0,5}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:)))$/i}},On=class{constructor(e,t,n=0){this.offset=t,this.length=n,this.parent=e}get children(){return[]}toString(){return"type: "+this.type+" ("+this.offset+"/"+this.length+")"+(this.parent?" parent: {"+this.parent.toString()+"}":"")}},Mn=class extends On{constructor(e,t){super(e,t),this.type="null",this.value=null}},Rn=class extends On{constructor(e,t,n){super(e,n),this.type="boolean",this.value=t}},Dn=class extends On{constructor(e,t){super(e,t),this.type="array",this.items=[]}get children(){return this.items}},Bn=class extends On{constructor(e,t){super(e,t),this.type="number",this.isInteger=!0,this.value=Number.NaN}},Fn=class extends On{constructor(e,t,n){super(e,t,n),this.type="string",this.value=""}},Pn=class extends On{constructor(e,t,n){super(e,t),this.type="property",this.colonOffset=-1,this.keyNode=n}get children(){return this.valueNode?[this.keyNode,this.valueNode]:[this.keyNode]}},Vn=class extends On{constructor(e,t){super(e,t),this.type="object",this.properties=[]}get children(){return this.properties}};function zn(e){return on(e)?e?{}:{not:{}}:e}(An=Tn||(Tn={}))[An.Key=0]="Key",An[An.Enum=1]="Enum";var jn={"http://json-schema.org/draft-03/schema#":_n.v3,"http://json-schema.org/draft-04/schema#":_n.v4,"http://json-schema.org/draft-06/schema#":_n.v6,"http://json-schema.org/draft-07/schema#":_n.v7,"https://json-schema.org/draft/2019-09/schema":_n.v2019_09,"https://json-schema.org/draft/2020-12/schema":_n.v2020_12},qn=class{constructor(e){this.schemaDraft=e}},Wn=class e{constructor(e=-1,t){this.focusOffset=e,this.exclude=t,this.schemas=[]}add(e){this.schemas.push(e)}merge(e){Array.prototype.push.apply(this.schemas,e.schemas)}include(e){return(-1===this.focusOffset||Gn(e,this.focusOffset))&&e!==this.exclude}newSub(){return new e(-1,this.exclude)}},Un=class{constructor(){}get schemas(){return[]}add(e){}merge(e){}include(e){return!0}newSub(){return this}};Un.instance=new Un;var $n=class{constructor(){this.problems=[],this.propertiesMatches=0,this.processedProperties=new Set,this.propertiesValueMatches=0,this.primaryValueMatches=0,this.enumValueMatch=!1,this.enumValues=void 0}hasProblems(){return!!this.problems.length}merge(e){this.problems=this.problems.concat(e.problems),this.propertiesMatches+=e.propertiesMatches,this.propertiesValueMatches+=e.propertiesValueMatches,this.mergeProcessedProperties(e)}mergeEnumValues(e){if(!this.enumValueMatch&&!e.enumValueMatch&&this.enumValues&&e.enumValues){this.enumValues=this.enumValues.concat(e.enumValues);for(const e of this.problems)e.code===pn.EnumValueMismatch&&(e.message=xn("Value is not accepted. Valid values: {0}.",this.enumValues.map((e=>JSON.stringify(e))).join(", ")))}}mergePropertyMatch(e){this.problems=this.problems.concat(e.problems),this.propertiesMatches++,(e.enumValueMatch||!e.hasProblems()&&e.propertiesMatches)&&this.propertiesValueMatches++,e.enumValueMatch&&e.enumValues&&1===e.enumValues.length&&this.primaryValueMatches++}mergeProcessedProperties(e){e.processedProperties.forEach((e=>this.processedProperties.add(e)))}compare(e){const t=this.hasProblems();return t!==e.hasProblems()?t?-1:1:this.enumValueMatch!==e.enumValueMatch?e.enumValueMatch?-1:1:this.primaryValueMatches!==e.primaryValueMatches?this.primaryValueMatches-e.primaryValueMatches:this.propertiesValueMatches!==e.propertiesValueMatches?this.propertiesValueMatches-e.propertiesValueMatches:this.propertiesMatches-e.propertiesMatches}};function Hn(e){return tn(e)}function Kn(e){return en(e)}function Gn(e,t,n=!1){return t>=e.offset&&t{let r=e(n);const i=n.children;if(Array.isArray(i))for(let e=0;e{const r=D.create(e.positionAt(t.location.offset),e.positionAt(t.location.offset+t.location.length));return ie.create(r,t.message,t.severity??n,t.code)}))}}getMatchingSchemas(e,t=-1,n){if(this.root&&e){const r=new Wn(t,n),i=Jn(e),s=new qn(i);return Xn(this.root,e,new $n,r,s),r.schemas}return[]}};function Jn(e,t=_n.v2020_12){let n=e.$schema;return n?jn[n]??t:t}function Xn(e,t,n,r,i){if(!e||!r.include(e))return;if("property"===e.type)return Xn(e.valueNode,t,n,r,i);const s=e;switch(function(){function e(e){return s.type===e||"integer"===e&&"number"===s.type&&s.isInteger}Array.isArray(t.type)?t.type.some(e)||n.problems.push({location:{offset:s.offset,length:s.length},message:t.errorMessage||xn("Incorrect type. Expected one of {0}.",t.type.join(", "))}):t.type&&(e(t.type)||n.problems.push({location:{offset:s.offset,length:s.length},message:t.errorMessage||xn('Incorrect type. Expected "{0}".',t.type)}));if(Array.isArray(t.allOf))for(const u of t.allOf){const e=new $n,t=r.newSub();Xn(s,zn(u),e,t,i),n.merge(e),r.merge(t)}const o=zn(t.not);if(o){const e=new $n,a=r.newSub();Xn(s,o,e,a,i),e.hasProblems()||n.problems.push({location:{offset:s.offset,length:s.length},message:t.errorMessage||xn("Matches a schema that is not allowed.")});for(const t of a.schemas)t.inverted=!t.inverted,r.add(t)}const a=(e,t)=>{const o=[];let a;for(const n of e){const e=zn(n),l=new $n,c=r.newSub();if(Xn(s,e,l,c,i),l.hasProblems()||o.push(e),a)if(t||l.hasProblems()||a.validationResult.hasProblems()){const t=l.compare(a.validationResult);t>0?a={schema:e,validationResult:l,matchingSchemas:c}:0===t&&(a.matchingSchemas.merge(c),a.validationResult.mergeEnumValues(l))}else a.matchingSchemas.merge(c),a.validationResult.propertiesMatches+=l.propertiesMatches,a.validationResult.propertiesValueMatches+=l.propertiesValueMatches,a.validationResult.mergeProcessedProperties(l);else a={schema:e,validationResult:l,matchingSchemas:c}}return o.length>1&&t&&n.problems.push({location:{offset:s.offset,length:1},message:xn("Matches multiple schemas when only one must validate.")}),a&&(n.merge(a.validationResult),r.merge(a.matchingSchemas)),o.length};Array.isArray(t.anyOf)&&a(t.anyOf,!1);Array.isArray(t.oneOf)&&a(t.oneOf,!0);const l=e=>{const t=new $n,o=r.newSub();Xn(s,zn(e),t,o,i),n.merge(t),r.merge(o)},c=zn(t.if);c&&((e,t,o)=>{const a=zn(e),c=new $n,h=r.newSub();Xn(s,a,c,h,i),r.merge(h),n.mergeProcessedProperties(c),c.hasProblems()?o&&l(o):t&&l(t)})(c,zn(t.then),zn(t.else));if(Array.isArray(t.enum)){const e=Hn(s);let r=!1;for(const n of t.enum)if(nn(e,n)){r=!0;break}n.enumValues=t.enum,n.enumValueMatch=r,r||n.problems.push({location:{offset:s.offset,length:s.length},code:pn.EnumValueMismatch,message:t.errorMessage||xn("Value is not accepted. Valid values: {0}.",t.enum.map((e=>JSON.stringify(e))).join(", "))})}if(sn(t.const)){nn(Hn(s),t.const)?n.enumValueMatch=!0:(n.problems.push({location:{offset:s.offset,length:s.length},code:pn.EnumValueMismatch,message:t.errorMessage||xn("Value must be {0}.",JSON.stringify(t.const))}),n.enumValueMatch=!1),n.enumValues=[t.const]}let h=t.deprecationMessage;if(h||t.deprecated){h=h||xn("Value is deprecated");let e="property"===s.parent?.type?s.parent:s;n.problems.push({location:{offset:e.offset,length:e.length},severity:Z.Warning,message:h,code:pn.Deprecated})}}(),s.type){case"object":!function(e){const s=Object.create(null),o=new Set;for(const t of e.properties){const e=t.keyNode.value;s[e]=t.valueNode,o.add(e)}if(Array.isArray(t.required))for(const r of t.required)if(!s[r]){const t=e.parent&&"property"===e.parent.type&&e.parent.keyNode,i=t?{offset:t.offset,length:t.length}:{offset:e.offset,length:1};n.problems.push({location:i,message:xn('Missing property "{0}".',r)})}const a=e=>{o.delete(e),n.processedProperties.add(e)};if(t.properties)for(const d of Object.keys(t.properties)){a(d);const e=t.properties[d],o=s[d];if(o)if(on(e))if(e)n.propertiesMatches++,n.propertiesValueMatches++;else{const e=o.parent;n.problems.push({location:{offset:e.keyNode.offset,length:e.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",d)})}else{const t=new $n;Xn(o,e,t,r,i),n.mergePropertyMatch(t)}}if(t.patternProperties)for(const d of Object.keys(t.patternProperties)){const e=hn(d);if(e){const l=[];for(const a of o)if(e.test(a)){l.push(a);const e=s[a];if(e){const s=t.patternProperties[d];if(on(s))if(s)n.propertiesMatches++,n.propertiesValueMatches++;else{const r=e.parent;n.problems.push({location:{offset:r.keyNode.offset,length:r.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",a)})}else{const t=new $n;Xn(e,s,t,r,i),n.mergePropertyMatch(t)}}}l.forEach(a)}}const l=t.additionalProperties;if(void 0!==l)for(const d of o){a(d);const e=s[d];if(e)if(!1===l){const r=e.parent;n.problems.push({location:{offset:r.keyNode.offset,length:r.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",d)})}else if(!0!==l){const t=new $n;Xn(e,l,t,r,i),n.mergePropertyMatch(t)}}const c=t.unevaluatedProperties;if(void 0!==c){const e=[];for(const a of o)if(!n.processedProperties.has(a)){e.push(a);const o=s[a];if(o)if(!1===c){const e=o.parent;n.problems.push({location:{offset:e.keyNode.offset,length:e.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",a)})}else if(!0!==c){const e=new $n;Xn(o,c,e,r,i),n.mergePropertyMatch(e)}}e.forEach(a)}rn(t.maxProperties)&&e.properties.length>t.maxProperties&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Object has more properties than limit of {0}.",t.maxProperties)});rn(t.minProperties)&&e.properties.length=_n.v2020_12?(s=t.prefixItems,o=Array.isArray(t.items)?void 0:t.items):(s=Array.isArray(t.items)?t.items:void 0,o=Array.isArray(t.items)?t.additionalItems:t.items);let a=0;if(void 0!==s){const t=Math.min(s.length,e.items.length);for(;a=_n.v2020_12&&n.processedProperties.add(String(t)))}0!==r||rn(t.minContains)||n.problems.push({location:{offset:e.offset,length:e.length},message:t.errorMessage||xn("Array does not contain required item.")}),rn(t.minContains)&&rt.maxContains&&n.problems.push({location:{offset:e.offset,length:e.length},message:t.errorMessage||xn("Array has too many items that match the contains contraint. Expected {0} or less.",t.maxContains)})}const c=t.unevaluatedItems;if(void 0!==c)for(let h=0;ht.maxItems&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Array has too many items. Expected {0} or fewer.",t.maxItems)});if(!0===t.uniqueItems){let t=function(){for(let e=0;et.maxLength&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("String is longer than the maximum length of {0}.",t.maxLength)});if(an(t.pattern)){const r=hn(t.pattern);r?.test(e.value)||n.problems.push({location:{offset:e.offset,length:e.length},message:t.patternErrorMessage||t.errorMessage||xn('String does not match the pattern of "{0}".',t.pattern)})}if(t.format)switch(t.format){case"uri":case"uri-reference":{let r;if(e.value){const n=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/.exec(e.value);n?n[2]||"uri"!==t.format||(r=xn("URI with a scheme is expected.")):r=xn("URI is expected.")}else r=xn("URI expected.");r&&n.problems.push({location:{offset:e.offset,length:e.length},message:t.patternErrorMessage||t.errorMessage||xn("String is not a URI: {0}",r)})}break;case"color-hex":case"date-time":case"date":case"time":case"email":case"hostname":case"ipv4":case"ipv6":const r=In[t.format];e.value&&r.pattern.exec(e.value)||n.problems.push({location:{offset:e.offset,length:e.length},message:t.patternErrorMessage||t.errorMessage||r.errorMessage})}}(s);break;case"number":!function(e){const r=e.value;function i(e){const t=/^(-?\d+)(?:\.(\d+))?(?:e([-+]\d+))?$/.exec(e.toString());return t&&{value:Number(t[1]+(t[2]||"")),multiplier:(t[2]?.length||0)-(parseInt(t[3])||0)}}if(rn(t.multipleOf)){let s=-1;if(Number.isInteger(t.multipleOf))s=r%t.multipleOf;else{let e=i(t.multipleOf),n=i(r);if(e&&n){const t=10**Math.abs(n.multiplier-e.multiplier);n.multiplier=l&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Value is above the exclusive maximum of {0}.",l)});const c=o(t.minimum,t.exclusiveMinimum);rn(c)&&rh&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Value is above the maximum of {0}.",h)})}(s)}r.add({node:s,schema:t})}function Yn(e,t){const n=[];let r=-1;const i=e.getText(),s=w(i,!1),o=t&&t.collectComments?[]:void 0;function a(){for(;;){const t=s.scan();switch(h(),t){case 12:case 13:Array.isArray(o)&&o.push(D.create(e.positionAt(s.getTokenOffset()),e.positionAt(s.getTokenOffset()+s.getTokenLength())));break;case 15:case 14:break;default:return t}}}function l(t,i,s,o,a=Z.Error){if(0===n.length||s!==r){const l=D.create(e.positionAt(s),e.positionAt(o));n.push(ie.create(l,t,a,i,e.languageId)),r=s}}function c(e,t,n=void 0,r=[],o=[]){let c=s.getTokenOffset(),h=s.getTokenOffset()+s.getTokenLength();if(c===h&&c>0){for(c--;c>0&&/\s/.test(i.charAt(c));)c--;h=c+1}if(l(e,t,c,h),n&&u(n,!1),r.length+o.length>0){let e=s.getToken();for(;17!==e;){if(-1!==r.indexOf(e)){a();break}if(-1!==o.indexOf(e))break;e=a()}}return n}function h(){switch(s.getTokenError()){case 4:return c(xn("Invalid unicode sequence in string."),pn.InvalidUnicode),!0;case 5:return c(xn("Invalid escape character in string."),pn.InvalidEscapeCharacter),!0;case 3:return c(xn("Unexpected end of number."),pn.UnexpectedEndOfNumber),!0;case 1:return c(xn("Unexpected end of comment."),pn.UnexpectedEndOfComment),!0;case 2:return c(xn("Unexpected end of string."),pn.UnexpectedEndOfString),!0;case 6:return c(xn("Invalid characters in string. Control characters must be escaped."),pn.InvalidCharacter),!0}return!1}function u(e,t){return e.length=s.getTokenOffset()+s.getTokenLength()-e.offset,t&&a(),e}const d=new Fn(void 0,0,0);function g(t,n){const r=new Pn(t,s.getTokenOffset(),d);let i=f(r);if(!i){if(16!==s.getToken())return;{c(xn("Property keys must be doublequoted"),pn.PropertyKeysMustBeDoublequoted);const e=new Fn(r,s.getTokenOffset(),s.getTokenLength());e.value=s.getTokenValue(),i=e,a()}}if(r.keyNode=i,"//"!==i.value){const e=n[i.value];e?(l(xn("Duplicate object key"),pn.DuplicateKey,r.keyNode.offset,r.keyNode.offset+r.keyNode.length,Z.Warning),ln(e)&&l(xn("Duplicate object key"),pn.DuplicateKey,e.keyNode.offset,e.keyNode.offset+e.keyNode.length,Z.Warning),n[i.value]=!0):n[i.value]=r}if(6===s.getToken())r.colonOffset=s.getTokenOffset(),a();else if(c(xn("Colon expected"),pn.ColonExpected),10===s.getToken()&&e.positionAt(i.offset+i.length).line=0;t--){const n=this.contributions[t].resolveCompletion;if(n){const t=n(e);if(t)return t}}return this.promiseConstructor.resolve(e)}doComplete(e,t,n){const r={items:[],isIncomplete:!1},i=e.getText(),s=e.offsetAt(t);let o=n.getNodeFromOffset(s,!0);if(this.isInComment(e,o?o.offset:0,s))return Promise.resolve(r);if(o&&s===o.offset+o.length&&s>0){const e=i[s-1];("object"===o.type&&"}"===e||"array"===o.type&&"]"===e)&&(o=o.parent)}const a=this.getCurrentWord(e,s);let l;if(!o||"string"!==o.type&&"number"!==o.type&&"boolean"!==o.type&&"null"!==o.type){let n=s-a.length;n>0&&'"'===i[n-1]&&n--,l=D.create(e.positionAt(n),t)}else l=D.create(e.positionAt(o.offset),e.positionAt(o.offset+o.length));const c=new Map,h={add:e=>{let t=e.label;const n=c.get(t);if(n)n.documentation||(n.documentation=e.documentation),n.detail||(n.detail=e.detail),n.labelDetails||(n.labelDetails=e.labelDetails);else{if(t=t.replace(/[\n]/g,"\u21b5"),t.length>60){const e=t.substr(0,57).trim()+"...";c.has(e)||(t=e)}e.textEdit=le.replace(l,e.insertText),e.label=t,c.set(t,e),r.items.push(e)}},setAsIncomplete:()=>{r.isIncomplete=!0},error:e=>{console.error(e)},getNumberOfProposals:()=>r.items.length};return this.schemaService.getSchemaForResource(e.uri,n).then((t=>{const u=[];let d,g=!0,f="";if(o&&"string"===o.type){const e=o.parent;e&&"property"===e.type&&e.keyNode===o&&(g=!e.valueNode,d=e,f=i.substr(o.offset+1,o.length-2),e&&(o=e.parent))}if(o&&"object"===o.type){if(o.offset===s)return r;o.properties.forEach((e=>{d&&d===e||c.set(e.keyNode.value,$e.create("__"))}));let m="";g&&(m=this.evaluateSeparatorAfter(e,e.offsetAt(l.end))),t?this.getPropertyCompletions(t,n,o,g,m,h):this.getSchemaLessPropertyCompletions(n,o,f,h);const p=Kn(o);this.contributions.forEach((t=>{const n=t.collectPropertyCompletions(e.uri,p,a,g,""===m,h);n&&u.push(n)})),!t&&a.length>0&&'"'!==i.charAt(s-a.length-1)&&(h.add({kind:De.Property,label:this.getLabelForValue(a),insertText:this.getInsertTextForProperty(a,void 0,!1,m),insertTextFormat:Fe.Snippet,documentation:""}),h.setAsIncomplete())}const m={};return t?this.getValueCompletions(t,n,o,s,e,h,m):this.getSchemaLessValueCompletions(n,o,s,e,h),this.contributions.length>0&&this.getContributedValueCompletions(n,o,s,e,h,u),this.promiseConstructor.all(u).then((()=>{if(0===h.getNumberOfProposals()){let t=s;!o||"string"!==o.type&&"number"!==o.type&&"boolean"!==o.type&&"null"!==o.type||(t=o.offset+o.length);const n=this.evaluateSeparatorAfter(e,t);this.addFillerValueCompletions(m,n,h)}return r}))}))}getPropertyCompletions(e,t,n,r,i,s){t.getMatchingSchemas(e.schema,n.offset).forEach((e=>{if(e.node===n&&!e.inverted){const t=e.schema.properties;t&&Object.keys(t).forEach((e=>{const n=t[e];if("object"===typeof n&&!n.deprecationMessage&&!n.doNotSuggest){const t={kind:De.Property,label:e,insertText:this.getInsertTextForProperty(e,n,r,i),insertTextFormat:Fe.Snippet,filterText:this.getFilterTextForValue(e),documentation:this.fromMarkup(n.markdownDescription)||n.description||""};void 0!==n.suggestSortText&&(t.sortText=n.suggestSortText),t.insertText&&cn(t.insertText,`$1${i}`)&&(t.command={title:"Suggest",command:"editor.action.triggerSuggest"}),s.add(t)}}));const n=e.schema.propertyNames;if("object"===typeof n&&!n.deprecationMessage&&!n.doNotSuggest){const e=(e,t=void 0)=>{const o={kind:De.Property,label:e,insertText:this.getInsertTextForProperty(e,void 0,r,i),insertTextFormat:Fe.Snippet,filterText:this.getFilterTextForValue(e),documentation:t||this.fromMarkup(n.markdownDescription)||n.description||""};void 0!==n.suggestSortText&&(o.sortText=n.suggestSortText),o.insertText&&cn(o.insertText,`$1${i}`)&&(o.command={title:"Suggest",command:"editor.action.triggerSuggest"}),s.add(o)};if(n.enum)for(let t=0;t{e.properties.forEach((e=>{const t=e.keyNode.value;r.add({kind:De.Property,label:t,insertText:this.getInsertTextForValue(t,""),insertTextFormat:Fe.Snippet,filterText:this.getFilterTextForValue(t),documentation:""})}))};if(t.parent)if("property"===t.parent.type){const n=t.parent.keyNode.value;e.visit((e=>("property"===e.type&&e!==t.parent&&e.keyNode.value===n&&e.valueNode&&"object"===e.valueNode.type&&i(e.valueNode),!0)))}else"array"===t.parent.type&&t.parent.items.forEach((e=>{"object"===e.type&&e!==t&&i(e)}));else"object"===t.type&&r.add({kind:De.Property,label:"$schema",insertText:this.getInsertTextForProperty("$schema",void 0,!0,""),insertTextFormat:Fe.Snippet,documentation:"",filterText:this.getFilterTextForValue("$schema")})}getSchemaLessValueCompletions(e,t,n,r,i){let s=n;if(!t||"string"!==t.type&&"number"!==t.type&&"boolean"!==t.type&&"null"!==t.type||(s=t.offset+t.length,t=t.parent),!t)return i.add({kind:this.getSuggestionKind("object"),label:"Empty object",insertText:this.getInsertTextForValue({},""),insertTextFormat:Fe.Snippet,documentation:""}),void i.add({kind:this.getSuggestionKind("array"),label:"Empty array",insertText:this.getInsertTextForValue([],""),insertTextFormat:Fe.Snippet,documentation:""});const o=this.evaluateSeparatorAfter(r,s),a=e=>{e.parent&&!Gn(e.parent,n,!0)&&i.add({kind:this.getSuggestionKind(e.type),label:this.getLabelTextForMatchingNode(e,r),insertText:this.getInsertTextForMatchingNode(e,r,o),insertTextFormat:Fe.Snippet,documentation:""}),"boolean"===e.type&&this.addBooleanValueCompletion(!e.value,o,i)};if("property"===t.type&&n>(t.colonOffset||0)){const r=t.valueNode;if(r&&(n>r.offset+r.length||"object"===r.type||"array"===r.type))return;const s=t.keyNode.value;e.visit((e=>("property"===e.type&&e.keyNode.value===s&&e.valueNode&&a(e.valueNode),!0))),"$schema"===s&&t.parent&&!t.parent.parent&&this.addDollarSchemaCompletions(o,i)}if("array"===t.type)if(t.parent&&"property"===t.parent.type){const n=t.parent.keyNode.value;e.visit((e=>("property"===e.type&&e.keyNode.value===n&&e.valueNode&&"array"===e.valueNode.type&&e.valueNode.items.forEach(a),!0)))}else t.items.forEach(a)}getValueCompletions(e,t,n,r,i,s,o){let a,l,c=r;if(!n||"string"!==n.type&&"number"!==n.type&&"boolean"!==n.type&&"null"!==n.type||(c=n.offset+n.length,l=n,n=n.parent),n){if("property"===n.type&&r>(n.colonOffset||0)){const e=n.valueNode;if(e&&r>e.offset+e.length)return;a=n.keyNode.value,n=n.parent}if(n&&(void 0!==a||"array"===n.type)){const h=this.evaluateSeparatorAfter(i,c),u=t.getMatchingSchemas(e.schema,n.offset,l);for(const e of u)if(e.node===n&&!e.inverted&&e.schema){if("array"===n.type&&e.schema.items){let t=s;if(e.schema.uniqueItems){const e=new Set;n.children.forEach((t=>{"array"!==t.type&&"object"!==t.type&&e.add(this.getLabelForValue(Hn(t)))})),t={...s,add(t){e.has(t.label)||s.add(t)}}}if(Array.isArray(e.schema.items)){const s=this.findItemAtOffset(n,i,r);s(t.colonOffset||0)){const e=t.keyNode.value,o=t.valueNode;if((!o||n<=o.offset+o.length)&&t.parent){const n=Kn(t.parent);this.contributions.forEach((t=>{const o=t.collectValueCompletions(r.uri,n,e,i);o&&s.push(o)}))}}}else this.contributions.forEach((e=>{const t=e.collectDefaultCompletions(r.uri,i);t&&s.push(t)}))}addSchemaValueCompletions(e,t,n,r){"object"===typeof e&&(this.addEnumValueCompletions(e,t,n),this.addDefaultValueCompletions(e,t,n),this.collectTypes(e,r),Array.isArray(e.allOf)&&e.allOf.forEach((e=>this.addSchemaValueCompletions(e,t,n,r))),Array.isArray(e.anyOf)&&e.anyOf.forEach((e=>this.addSchemaValueCompletions(e,t,n,r))),Array.isArray(e.oneOf)&&e.oneOf.forEach((e=>this.addSchemaValueCompletions(e,t,n,r))))}addDefaultValueCompletions(e,t,n,r=0){let i=!1;if(sn(e.default)){let s=e.type,o=e.default;for(let e=r;e>0;e--)o=[o],s="array";const a={kind:this.getSuggestionKind(s),label:this.getLabelForValue(o),insertText:this.getInsertTextForValue(o,t),insertTextFormat:Fe.Snippet};this.doesSupportsLabelDetails()?a.labelDetails={description:xn("Default value")}:a.detail=xn("Default value"),n.add(a),i=!0}Array.isArray(e.examples)&&e.examples.forEach((s=>{let o=e.type,a=s;for(let e=r;e>0;e--)a=[a],o="array";n.add({kind:this.getSuggestionKind(o),label:this.getLabelForValue(a),insertText:this.getInsertTextForValue(a,t),insertTextFormat:Fe.Snippet}),i=!0})),Array.isArray(e.defaultSnippets)&&e.defaultSnippets.forEach((s=>{let o,a,l=e.type,c=s.body,h=s.label;if(sn(c)){let n=e.type;for(let e=r;e>0;e--)c=[c],n="array";o=this.getInsertTextForSnippetValue(c,t),a=this.getFilterTextForSnippetValue(c),h=h||this.getLabelForSnippetValue(c)}else{if("string"!==typeof s.bodyText)return;{let e="",n="",i="";for(let t=r;t>0;t--)e=e+i+"[\n",n=n+"\n"+i+"]",i+="\t",l="array";o=e+i+s.bodyText.split("\n").join("\n"+i)+n+t,h=h||o,a=o.replace(/[\n]/g,"")}}n.add({kind:this.getSuggestionKind(l),label:h,documentation:this.fromMarkup(s.markdownDescription)||s.description,insertText:o,insertTextFormat:Fe.Snippet,filterText:a}),i=!0})),!i&&"object"===typeof e.items&&!Array.isArray(e.items)&&r<5&&this.addDefaultValueCompletions(e.items,t,n,r+1)}addEnumValueCompletions(e,t,n){if(sn(e.const)&&n.add({kind:this.getSuggestionKind(e.type),label:this.getLabelForValue(e.const),insertText:this.getInsertTextForValue(e.const,t),insertTextFormat:Fe.Snippet,documentation:this.fromMarkup(e.markdownDescription)||e.description}),Array.isArray(e.enum))for(let r=0,i=e.enum.length;rt[e]=!0)):n&&(t[n]=!0)}addFillerValueCompletions(e,t,n){e.object&&n.add({kind:this.getSuggestionKind("object"),label:"{}",insertText:this.getInsertTextForGuessedValue({},t),insertTextFormat:Fe.Snippet,detail:xn("New object"),documentation:""}),e.array&&n.add({kind:this.getSuggestionKind("array"),label:"[]",insertText:this.getInsertTextForGuessedValue([],t),insertTextFormat:Fe.Snippet,detail:xn("New array"),documentation:""})}addBooleanValueCompletion(e,t,n){n.add({kind:this.getSuggestionKind("boolean"),label:e?"true":"false",insertText:this.getInsertTextForValue(e,t),insertTextFormat:Fe.Snippet,documentation:""})}addNullValueCompletion(e,t){t.add({kind:this.getSuggestionKind("null"),label:"null",insertText:"null"+e,insertTextFormat:Fe.Snippet,documentation:""})}addDollarSchemaCompletions(e,t){this.schemaService.getRegisteredSchemaIds((e=>"http"===e||"https"===e)).forEach((n=>{n.startsWith("http://json-schema.org/draft-")&&(n+="#"),t.add({kind:De.Module,label:this.getLabelForValue(n),filterText:this.getFilterTextForValue(n),insertText:this.getInsertTextForValue(n,e),insertTextFormat:Fe.Snippet,documentation:""})}))}getLabelForValue(e){return JSON.stringify(e)}getValueFromLabel(e){return JSON.parse(e)}getFilterTextForValue(e){return JSON.stringify(e)}getFilterTextForSnippetValue(e){return JSON.stringify(e).replace(/\$\{\d+:([^}]+)\}|\$\d+/g,"$1")}getLabelForSnippetValue(e){return JSON.stringify(e).replace(/\$\{\d+:([^}]+)\}|\$\d+/g,"$1")}getInsertTextForPlainText(e){return e.replace(/[\\\$\}]/g,"\\$&")}getInsertTextForValue(e,t){const n=JSON.stringify(e,null,"\t");return"{}"===n?"{$1}"+t:"[]"===n?"[$1]"+t:this.getInsertTextForPlainText(n+t)}getInsertTextForSnippetValue(e,t){return Zn(e,"",(e=>"string"===typeof e&&"^"===e[0]?e.substr(1):JSON.stringify(e)))+t}getInsertTextForGuessedValue(e,t){switch(typeof e){case"object":return null===e?"${1:null}"+t:this.getInsertTextForValue(e,t);case"string":let n=JSON.stringify(e);return n=n.substr(1,n.length-2),n=this.getInsertTextForPlainText(n),'"${1:'+n+'}"'+t;case"number":case"boolean":return"${1:"+JSON.stringify(e)+"}"+t}return this.getInsertTextForValue(e,t)}getSuggestionKind(e){if(Array.isArray(e)){const t=e;e=t.length>0?t[0]:void 0}if(!e)return De.Value;switch(e){case"string":default:return De.Value;case"object":return De.Module;case"property":return De.Property}}getLabelTextForMatchingNode(e,t){switch(e.type){case"array":return"[]";case"object":return"{}";default:return t.getText().substr(e.offset,e.length)}}getInsertTextForMatchingNode(e,t,n){switch(e.type){case"array":return this.getInsertTextForValue([],n);case"object":return this.getInsertTextForValue({},n);default:const r=t.getText().substr(e.offset,e.length)+n;return this.getInsertTextForPlainText(r)}}getInsertTextForProperty(e,t,n,r){const i=this.getInsertTextForValue(e,"");if(!n)return i;const s=i+": ";let o,a=0;if(t){if(Array.isArray(t.defaultSnippets)){if(1===t.defaultSnippets.length){const e=t.defaultSnippets[0].body;sn(e)&&(o=this.getInsertTextForSnippetValue(e,""))}a+=t.defaultSnippets.length}if(t.enum&&(o||1!==t.enum.length||(o=this.getInsertTextForGuessedValue(t.enum[0],"")),a+=t.enum.length),sn(t.const)&&(o||(o=this.getInsertTextForGuessedValue(t.const,"")),a++),sn(t.default)&&(o||(o=this.getInsertTextForGuessedValue(t.default,"")),a++),Array.isArray(t.examples)&&t.examples.length&&(o||(o=this.getInsertTextForGuessedValue(t.examples[0],"")),a+=t.examples.length),0===a){let e=Array.isArray(t.type)?t.type[0]:t.type;switch(e||(t.properties?e="object":t.items&&(e="array")),e){case"boolean":o="$1";break;case"string":o='"$1"';break;case"object":o="{$1}";break;case"array":o="[$1]";break;case"number":case"integer":o="${1:0}";break;case"null":o="${1:null}";break;default:return i}}}return(!o||a>1)&&(o="$1"),s+o+r}getCurrentWord(e,t){let n=t-1;const r=e.getText();for(;n>=0&&-1===' \t\n\r\v":{[,]}'.indexOf(r.charAt(n));)n--;return r.substring(n+1,t)}evaluateSeparatorAfter(e,t){const n=w(e.getText(),!0);n.setPosition(t);switch(n.scan()){case 5:case 2:case 4:case 17:return"";default:return","}}findItemAtOffset(e,t,n){const r=w(t.getText(),!0),i=e.items;for(let s=i.length-1;s>=0;s--){const e=i[s];if(n>e.offset+e.length){r.setPosition(e.offset+e.length);return 5===r.scan()&&n>=r.getTokenOffset()+r.getTokenLength()?s+1:s}if(n>=e.offset)return s}return 0}isInComment(e,t,n){const r=w(e.getText(),!1);r.setPosition(t);let i=r.scan();for(;17!==i&&r.getTokenOffset()+r.getTokenLength()i.offset+1&&r({contents:e,range:o}),l=Kn(i);for(let c=this.contributions.length-1;c>=0;c--){const t=this.contributions[c].getInfoContribution(e.uri,l);if(t)return t.then((e=>a(e)))}return this.schemaService.getSchemaForResource(e.uri,n).then((e=>{if(e&&i){let t,r,s,o;n.getMatchingSchemas(e.schema,i.offset).every((e=>{if(e.node===i&&!e.inverted&&e.schema&&(t=t||e.schema.title,r=r||e.schema.markdownDescription||nr(e.schema.description),e.schema.enum)){const t=e.schema.enum.indexOf(Hn(i));e.schema.markdownEnumDescriptions?s=e.schema.markdownEnumDescriptions[t]:e.schema.enumDescriptions&&(s=nr(e.schema.enumDescriptions[t])),s&&(o=e.schema.enum[t],"string"!==typeof o&&(o=JSON.stringify(o)))}return!0}));let l="";return t&&(l=nr(t)),r&&(l.length>0&&(l+="\n\n"),l+=r),s&&(l.length>0&&(l+="\n\n"),l+=`\`${function(e){if(-1!==e.indexOf("`"))return"`` "+e+" ``";return e}(o)}\`: ${s}`),a([l])}return null}))}};function nr(e){if(e){return e.replace(/([^\n\r])(\r?\n)([^\n\r])/gm,"$1\n\n$3").replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}}var rr=class{constructor(e,t){this.jsonSchemaService=e,this.promise=t,this.validationEnabled=!0}configure(e){e&&(this.validationEnabled=!1!==e.validate,this.commentSeverity=e.allowComments?void 0:Z.Error)}doValidation(e,t,n,r){if(!this.validationEnabled)return this.promise.resolve([]);const i=[],s={},o=e=>{const t=e.range.start.line+" "+e.range.start.character+" "+e.message;s[t]||(s[t]=!0,i.push(e))},a=r=>{let s=n?.trailingCommas?ar(n.trailingCommas):Z.Error,a=n?.comments?ar(n.comments):this.commentSeverity,l=n?.schemaValidation?ar(n.schemaValidation):Z.Warning,c=n?.schemaRequest?ar(n.schemaRequest):Z.Warning;if(r){const i=(n,r)=>{if(t.root&&c){const i=t.root,s="object"===i.type?i.properties[0]:void 0;if(s&&"$schema"===s.keyNode.value){const t=s.valueNode||s,i=D.create(e.positionAt(t.offset),e.positionAt(t.offset+t.length));o(ie.create(i,n,c,r))}else{const t=D.create(e.positionAt(i.offset),e.positionAt(i.offset+1));o(ie.create(t,n,c,r))}}};if(r.errors.length)i(r.errors[0],pn.SchemaResolveError);else if(l){for(const e of r.warnings)i(e,pn.SchemaUnsupportedFeature);const s=t.validate(e,r.schema,l,n?.schemaDraft);s&&s.forEach(o)}sr(r.schema)&&(a=void 0),or(r.schema)&&(s=void 0)}for(const e of t.syntaxErrors){if(e.code===pn.TrailingComma){if("number"!==typeof s)continue;e.severity=s}o(e)}if("number"===typeof a){const e=xn("Comments are not permitted in JSON.");t.comments.forEach((t=>{o(ie.create(t,e,a,pn.CommentNotPermitted))}))}return i};if(r){const e=r.id||"schemaservice://untitled/"+ir++;return this.jsonSchemaService.registerExternalSchema({uri:e,schema:r}).getResolvedSchema().then((e=>a(e)))}return this.jsonSchemaService.getSchemaForResource(e.uri,t).then((e=>a(e)))}getLanguageStatus(e,t){return{schemas:this.jsonSchemaService.getSchemaURIsForResource(e.uri,t)}}},ir=0;function sr(e){if(e&&"object"===typeof e){if(on(e.allowComments))return e.allowComments;if(e.allOf)for(const t of e.allOf){const e=sr(t);if(on(e))return e}}}function or(e){if(e&&"object"===typeof e){if(on(e.allowTrailingCommas))return e.allowTrailingCommas;const t=e;if(on(t.allowsTrailingCommas))return t.allowsTrailingCommas;if(e.allOf)for(const n of e.allOf){const e=or(n);if(on(e))return e}}}function ar(e){switch(e){case"error":return Z.Error;case"warning":return Z.Warning;case"ignore":return}}function lr(e){return e<48?0:e<=57?e-48:(e<97&&(e+=32),e>=97&&e<=102?e-97+10:0)}function cr(e){if("#"===e[0])switch(e.length){case 4:return{red:17*lr(e.charCodeAt(1))/255,green:17*lr(e.charCodeAt(2))/255,blue:17*lr(e.charCodeAt(3))/255,alpha:1};case 5:return{red:17*lr(e.charCodeAt(1))/255,green:17*lr(e.charCodeAt(2))/255,blue:17*lr(e.charCodeAt(3))/255,alpha:17*lr(e.charCodeAt(4))/255};case 7:return{red:(16*lr(e.charCodeAt(1))+lr(e.charCodeAt(2)))/255,green:(16*lr(e.charCodeAt(3))+lr(e.charCodeAt(4)))/255,blue:(16*lr(e.charCodeAt(5))+lr(e.charCodeAt(6)))/255,alpha:1};case 9:return{red:(16*lr(e.charCodeAt(1))+lr(e.charCodeAt(2)))/255,green:(16*lr(e.charCodeAt(3))+lr(e.charCodeAt(4)))/255,blue:(16*lr(e.charCodeAt(5))+lr(e.charCodeAt(6)))/255,alpha:(16*lr(e.charCodeAt(7))+lr(e.charCodeAt(8)))/255}}}var hr=class{constructor(e){this.schemaService=e}findDocumentSymbols(e,t,n={resultLimit:Number.MAX_VALUE}){const r=t.root;if(!r)return[];let i=n.resultLimit||Number.MAX_VALUE;const s=e.uri;if(("vscode://defaultsettings/keybindings.json"===s||cn(s.toLowerCase(),"/user/keybindings.json"))&&"array"===r.type){const t=[];for(const o of r.items)if("object"===o.type)for(const r of o.properties)if("key"===r.keyNode.value&&r.valueNode){const a=F.create(e.uri,ur(e,o));if(t.push({name:dr(r.valueNode),kind:tt.Function,location:a}),i--,i<=0)return n&&n.onResultLimitExceeded&&n.onResultLimitExceeded(s),t}return t}const o=[{node:r,containerName:""}];let a=0,l=!1;const c=[],h=(t,n)=>{"array"===t.type?t.items.forEach((e=>{e&&o.push({node:e,containerName:n})})):"object"===t.type&&t.properties.forEach((t=>{const r=t.valueNode;if(r)if(i>0){i--;const s=F.create(e.uri,ur(e,t)),a=n?n+"."+t.keyNode.value:t.keyNode.value;c.push({name:this.getKeyLabel(t),kind:this.getSymbolKind(r.type),location:s,containerName:n}),o.push({node:r,containerName:a})}else l=!0}))};for(;a{"array"===t.type?t.items.forEach(((t,r)=>{if(t)if(i>0){i--;const s=ur(e,t),o=s,l={name:String(r),kind:this.getSymbolKind(t.type),range:s,selectionRange:o,children:[]};n.push(l),a.push({result:l.children,node:t})}else c=!0})):"object"===t.type&&t.properties.forEach((t=>{const r=t.valueNode;if(r)if(i>0){i--;const s=ur(e,t),o=ur(e,t.keyNode),l=[],c={name:this.getKeyLabel(t),kind:this.getSymbolKind(r.type),range:s,selectionRange:o,children:l,detail:this.getDetail(r)};n.push(c),a.push({result:l,node:r})}else c=!0}))};for(;l{const i=[];if(r){let s=n&&"number"===typeof n.resultLimit?n.resultLimit:Number.MAX_VALUE;const o=t.getMatchingSchemas(r.schema),a={};for(const t of o)if(!t.inverted&&t.schema&&("color"===t.schema.format||"color-hex"===t.schema.format)&&t.node&&"string"===t.node.type){const r=String(t.node.offset);if(!a[r]){const o=cr(Hn(t.node));if(o){const n=ur(e,t.node);i.push({color:o,range:n})}if(a[r]=!0,s--,s<=0)return n&&n.onResultLimitExceeded&&n.onResultLimitExceeded(e.uri),i}}}return i}))}getColorPresentations(e,t,n,r){const i=[],s=Math.round(255*n.red),o=Math.round(255*n.green),a=Math.round(255*n.blue);function l(e){const t=e.toString(16);return 2!==t.length?"0"+t:t}let c;return c=1===n.alpha?`#${l(s)}${l(o)}${l(a)}`:`#${l(s)}${l(o)}${l(a)}${l(Math.round(255*n.alpha))}`,i.push({label:c,textEdit:le.replace(r,JSON.stringify(c))}),i}};function ur(e,t){return D.create(e.positionAt(t.offset),e.positionAt(t.offset+t.length))}function dr(e){return Hn(e)||xn("")}var gr,fr={schemaAssociations:[],schemas:{"http://json-schema.org/draft-04/schema#":{$schema:"http://json-schema.org/draft-04/schema#",definitions:{schemaArray:{type:"array",minItems:1,items:{$ref:"#"}},positiveInteger:{type:"integer",minimum:0},positiveIntegerDefault0:{allOf:[{$ref:"#/definitions/positiveInteger"},{default:0}]},simpleTypes:{type:"string",enum:["array","boolean","integer","null","number","object","string"]},stringArray:{type:"array",items:{type:"string"},minItems:1,uniqueItems:!0}},type:"object",properties:{id:{type:"string",format:"uri"},$schema:{type:"string",format:"uri"},title:{type:"string"},description:{type:"string"},default:{},multipleOf:{type:"number",minimum:0,exclusiveMinimum:!0},maximum:{type:"number"},exclusiveMaximum:{type:"boolean",default:!1},minimum:{type:"number"},exclusiveMinimum:{type:"boolean",default:!1},maxLength:{allOf:[{$ref:"#/definitions/positiveInteger"}]},minLength:{allOf:[{$ref:"#/definitions/positiveIntegerDefault0"}]},pattern:{type:"string",format:"regex"},additionalItems:{anyOf:[{type:"boolean"},{$ref:"#"}],default:{}},items:{anyOf:[{$ref:"#"},{$ref:"#/definitions/schemaArray"}],default:{}},maxItems:{allOf:[{$ref:"#/definitions/positiveInteger"}]},minItems:{allOf:[{$ref:"#/definitions/positiveIntegerDefault0"}]},uniqueItems:{type:"boolean",default:!1},maxProperties:{allOf:[{$ref:"#/definitions/positiveInteger"}]},minProperties:{allOf:[{$ref:"#/definitions/positiveIntegerDefault0"}]},required:{allOf:[{$ref:"#/definitions/stringArray"}]},additionalProperties:{anyOf:[{type:"boolean"},{$ref:"#"}],default:{}},definitions:{type:"object",additionalProperties:{$ref:"#"},default:{}},properties:{type:"object",additionalProperties:{$ref:"#"},default:{}},patternProperties:{type:"object",additionalProperties:{$ref:"#"},default:{}},dependencies:{type:"object",additionalProperties:{anyOf:[{$ref:"#"},{$ref:"#/definitions/stringArray"}]}},enum:{type:"array",minItems:1,uniqueItems:!0},type:{anyOf:[{$ref:"#/definitions/simpleTypes"},{type:"array",items:{$ref:"#/definitions/simpleTypes"},minItems:1,uniqueItems:!0}]},format:{anyOf:[{type:"string",enum:["date-time","uri","email","hostname","ipv4","ipv6","regex"]},{type:"string"}]},allOf:{allOf:[{$ref:"#/definitions/schemaArray"}]},anyOf:{allOf:[{$ref:"#/definitions/schemaArray"}]},oneOf:{allOf:[{$ref:"#/definitions/schemaArray"}]},not:{allOf:[{$ref:"#"}]}},dependencies:{exclusiveMaximum:["maximum"],exclusiveMinimum:["minimum"]},default:{}},"http://json-schema.org/draft-07/schema#":{definitions:{schemaArray:{type:"array",minItems:1,items:{$ref:"#"}},nonNegativeInteger:{type:"integer",minimum:0},nonNegativeIntegerDefault0:{allOf:[{$ref:"#/definitions/nonNegativeInteger"},{default:0}]},simpleTypes:{enum:["array","boolean","integer","null","number","object","string"]},stringArray:{type:"array",items:{type:"string"},uniqueItems:!0,default:[]}},type:["object","boolean"],properties:{$id:{type:"string",format:"uri-reference"},$schema:{type:"string",format:"uri"},$ref:{type:"string",format:"uri-reference"},$comment:{type:"string"},title:{type:"string"},description:{type:"string"},default:!0,readOnly:{type:"boolean",default:!1},examples:{type:"array",items:!0},multipleOf:{type:"number",exclusiveMinimum:0},maximum:{type:"number"},exclusiveMaximum:{type:"number"},minimum:{type:"number"},exclusiveMinimum:{type:"number"},maxLength:{$ref:"#/definitions/nonNegativeInteger"},minLength:{$ref:"#/definitions/nonNegativeIntegerDefault0"},pattern:{type:"string",format:"regex"},additionalItems:{$ref:"#"},items:{anyOf:[{$ref:"#"},{$ref:"#/definitions/schemaArray"}],default:!0},maxItems:{$ref:"#/definitions/nonNegativeInteger"},minItems:{$ref:"#/definitions/nonNegativeIntegerDefault0"},uniqueItems:{type:"boolean",default:!1},contains:{$ref:"#"},maxProperties:{$ref:"#/definitions/nonNegativeInteger"},minProperties:{$ref:"#/definitions/nonNegativeIntegerDefault0"},required:{$ref:"#/definitions/stringArray"},additionalProperties:{$ref:"#"},definitions:{type:"object",additionalProperties:{$ref:"#"},default:{}},properties:{type:"object",additionalProperties:{$ref:"#"},default:{}},patternProperties:{type:"object",additionalProperties:{$ref:"#"},propertyNames:{format:"regex"},default:{}},dependencies:{type:"object",additionalProperties:{anyOf:[{$ref:"#"},{$ref:"#/definitions/stringArray"}]}},propertyNames:{$ref:"#"},const:!0,enum:{type:"array",items:!0,minItems:1,uniqueItems:!0},type:{anyOf:[{$ref:"#/definitions/simpleTypes"},{type:"array",items:{$ref:"#/definitions/simpleTypes"},minItems:1,uniqueItems:!0}]},format:{type:"string"},contentMediaType:{type:"string"},contentEncoding:{type:"string"},if:{$ref:"#"},then:{$ref:"#"},else:{$ref:"#"},allOf:{$ref:"#/definitions/schemaArray"},anyOf:{$ref:"#/definitions/schemaArray"},oneOf:{$ref:"#/definitions/schemaArray"},not:{$ref:"#"}},default:!0}}},mr={id:xn("A unique identifier for the schema."),$schema:xn("The schema to verify this document against."),title:xn("A descriptive title of the element."),description:xn("A long description of the element. Used in hover menus and suggestions."),default:xn("A default value. Used by suggestions."),multipleOf:xn("A number that should cleanly divide the current value (i.e. have no remainder)."),maximum:xn("The maximum numerical value, inclusive by default."),exclusiveMaximum:xn("Makes the maximum property exclusive."),minimum:xn("The minimum numerical value, inclusive by default."),exclusiveMinimum:xn("Makes the minimum property exclusive."),maxLength:xn("The maximum length of a string."),minLength:xn("The minimum length of a string."),pattern:xn("A regular expression to match the string against. It is not implicitly anchored."),additionalItems:xn("For arrays, only when items is set as an array. If it is a schema, then this schema validates items after the ones specified by the items array. If it is false, then additional items will cause validation to fail."),items:xn("For arrays. Can either be a schema to validate every element against or an array of schemas to validate each item against in order (the first schema will validate the first element, the second schema will validate the second element, and so on."),maxItems:xn("The maximum number of items that can be inside an array. Inclusive."),minItems:xn("The minimum number of items that can be inside an array. Inclusive."),uniqueItems:xn("If all of the items in the array must be unique. Defaults to false."),maxProperties:xn("The maximum number of properties an object can have. Inclusive."),minProperties:xn("The minimum number of properties an object can have. Inclusive."),required:xn("An array of strings that lists the names of all properties required on this object."),additionalProperties:xn("Either a schema or a boolean. If a schema, then used to validate all properties not matched by 'properties' or 'patternProperties'. If false, then any properties not matched by either will cause this schema to fail."),definitions:xn("Not used for validation. Place subschemas here that you wish to reference inline with $ref."),properties:xn("A map of property names to schemas for each property."),patternProperties:xn("A map of regular expressions on property names to schemas for matching properties."),dependencies:xn("A map of property names to either an array of property names or a schema. An array of property names means the property named in the key depends on the properties in the array being present in the object in order to be valid. If the value is a schema, then the schema is only applied to the object if the property in the key exists on the object."),enum:xn("The set of literal values that are valid."),type:xn("Either a string of one of the basic schema types (number, integer, null, array, object, boolean, string) or an array of strings specifying a subset of those types."),format:xn("Describes the format expected for the value."),allOf:xn("An array of schemas, all of which must match."),anyOf:xn("An array of schemas, where at least one must match."),oneOf:xn("An array of schemas, exactly one of which must match."),not:xn("A schema which must not match."),$id:xn("A unique identifier for the schema."),$ref:xn("Reference a definition hosted on any location."),$comment:xn("Comments from schema authors to readers or maintainers of the schema."),readOnly:xn("Indicates that the value of the instance is managed exclusively by the owning authority."),examples:xn("Sample JSON values associated with a particular schema, for the purpose of illustrating usage."),contains:xn('An array instance is valid against "contains" if at least one of its elements is valid against the given schema.'),propertyNames:xn("If the instance is an object, this keyword validates if every property name in the instance validates against the provided schema."),const:xn("An instance validates successfully against this keyword if its value is equal to the value of the keyword."),contentMediaType:xn("Describes the media type of a string property."),contentEncoding:xn("Describes the content encoding of a string property."),if:xn('The validation outcome of the "if" subschema controls which of the "then" or "else" keywords are evaluated.'),then:xn('The "if" subschema is used for validation when the "if" subschema succeeds.'),else:xn('The "else" subschema is used for validation when the "if" subschema fails.')};for(const n in fr.schemas){const e=fr.schemas[n];for(const t in e.properties){let n=e.properties[t];"boolean"===typeof n&&(n=e.properties[t]={});const r=mr[t];r&&(n.description=r)}}(()=>{var e={470:e=>{function t(e){if("string"!=typeof e)throw new TypeError("Path must be a string. Received "+JSON.stringify(e))}function n(e,t){for(var n,r="",i=0,s=-1,o=0,a=0;a<=e.length;++a){if(a2){var l=r.lastIndexOf("/");if(l!==r.length-1){-1===l?(r="",i=0):i=(r=r.slice(0,l)).length-1-r.lastIndexOf("/"),s=a,o=0;continue}}else if(2===r.length||1===r.length){r="",i=0,s=a,o=0;continue}t&&(r.length>0?r+="/..":r="..",i=2)}else r.length>0?r+="/"+e.slice(s+1,a):r=e.slice(s+1,a),i=a-s-1;s=a,o=0}else 46===n&&-1!==o?++o:o=-1}return r}var r={resolve:function(){for(var e,r="",i=!1,s=arguments.length-1;s>=-1&&!i;s--){var o;s>=0?o=arguments[s]:(void 0===e&&(e=process.cwd()),o=e),t(o),0!==o.length&&(r=o+"/"+r,i=47===o.charCodeAt(0))}return r=n(r,!i),i?r.length>0?"/"+r:"/":r.length>0?r:"."},normalize:function(e){if(t(e),0===e.length)return".";var r=47===e.charCodeAt(0),i=47===e.charCodeAt(e.length-1);return 0!==(e=n(e,!r)).length||r||(e="."),e.length>0&&i&&(e+="/"),r?"/"+e:e},isAbsolute:function(e){return t(e),e.length>0&&47===e.charCodeAt(0)},join:function(){if(0===arguments.length)return".";for(var e,n=0;n0&&(void 0===e?e=i:e+="/"+i)}return void 0===e?".":r.normalize(e)},relative:function(e,n){if(t(e),t(n),e===n)return"";if((e=r.resolve(e))===(n=r.resolve(n)))return"";for(var i=1;ic){if(47===n.charCodeAt(a+u))return n.slice(a+u+1);if(0===u)return n.slice(a+u)}else o>c&&(47===e.charCodeAt(i+u)?h=u:0===u&&(h=0));break}var d=e.charCodeAt(i+u);if(d!==n.charCodeAt(a+u))break;47===d&&(h=u)}var g="";for(u=i+h+1;u<=s;++u)u!==s&&47!==e.charCodeAt(u)||(0===g.length?g+="..":g+="/..");return g.length>0?g+n.slice(a+h):(a+=h,47===n.charCodeAt(a)&&++a,n.slice(a))},_makeLong:function(e){return e},dirname:function(e){if(t(e),0===e.length)return".";for(var n=e.charCodeAt(0),r=47===n,i=-1,s=!0,o=e.length-1;o>=1;--o)if(47===(n=e.charCodeAt(o))){if(!s){i=o;break}}else s=!1;return-1===i?r?"/":".":r&&1===i?"//":e.slice(0,i)},basename:function(e,n){if(void 0!==n&&"string"!=typeof n)throw new TypeError('"ext" argument must be a string');t(e);var r,i=0,s=-1,o=!0;if(void 0!==n&&n.length>0&&n.length<=e.length){if(n.length===e.length&&n===e)return"";var a=n.length-1,l=-1;for(r=e.length-1;r>=0;--r){var c=e.charCodeAt(r);if(47===c){if(!o){i=r+1;break}}else-1===l&&(o=!1,l=r+1),a>=0&&(c===n.charCodeAt(a)?-1==--a&&(s=r):(a=-1,s=l))}return i===s?s=l:-1===s&&(s=e.length),e.slice(i,s)}for(r=e.length-1;r>=0;--r)if(47===e.charCodeAt(r)){if(!o){i=r+1;break}}else-1===s&&(o=!1,s=r+1);return-1===s?"":e.slice(i,s)},extname:function(e){t(e);for(var n=-1,r=0,i=-1,s=!0,o=0,a=e.length-1;a>=0;--a){var l=e.charCodeAt(a);if(47!==l)-1===i&&(s=!1,i=a+1),46===l?-1===n?n=a:1!==o&&(o=1):-1!==n&&(o=-1);else if(!s){r=a+1;break}}return-1===n||-1===i||0===o||1===o&&n===i-1&&n===r+1?"":e.slice(n,i)},format:function(e){if(null===e||"object"!=typeof e)throw new TypeError('The "pathObject" argument must be of type Object. Received type '+typeof e);return function(e,t){var n=t.dir||t.root,r=t.base||(t.name||"")+(t.ext||"");return n?n===t.root?n+r:n+"/"+r:r}(0,e)},parse:function(e){t(e);var n={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return n;var r,i=e.charCodeAt(0),s=47===i;s?(n.root="/",r=1):r=0;for(var o=-1,a=0,l=-1,c=!0,h=e.length-1,u=0;h>=r;--h)if(47!==(i=e.charCodeAt(h)))-1===l&&(c=!1,l=h+1),46===i?-1===o?o=h:1!==u&&(u=1):-1!==o&&(u=-1);else if(!c){a=h+1;break}return-1===o||-1===l||0===u||1===u&&o===l-1&&o===a+1?-1!==l&&(n.base=n.name=0===a&&s?e.slice(1,l):e.slice(a,l)):(0===a&&s?(n.name=e.slice(1,o),n.base=e.slice(1,l)):(n.name=e.slice(a,o),n.base=e.slice(a,l)),n.ext=e.slice(o,l)),a>0?n.dir=e.slice(0,a-1):s&&(n.dir="/"),n},sep:"/",delimiter:":",win32:null,posix:null};r.posix=r,e.exports=r}},t={};function n(r){var i=t[r];if(void 0!==i)return i.exports;var s=t[r]={exports:{}};return e[r](s,s.exports,n),s.exports}n.d=(e,t)=>{for(var r in t)n.o(t,r)&&!n.o(e,r)&&Object.defineProperty(e,r,{enumerable:!0,get:t[r]})},n.o=(e,t)=>Object.prototype.hasOwnProperty.call(e,t),n.r=e=>{"undefined"!=typeof Symbol&&Symbol.toStringTag&&Object.defineProperty(e,Symbol.toStringTag,{value:"Module"}),Object.defineProperty(e,"__esModule",{value:!0})};var r={};(()=>{let e;if(n.r(r),n.d(r,{URI:()=>h,Utils:()=>w}),"object"==typeof process)e="win32"===process.platform;else if("object"==typeof navigator){let t=navigator.userAgent;e=t.indexOf("Windows")>=0}const t=/^\w[\w\d+.-]*$/,i=/^\//,s=/^\/\//;function o(e,n){if(!e.scheme&&n)throw new Error(`[UriError]: Scheme is missing: {scheme: "", authority: "${e.authority}", path: "${e.path}", query: "${e.query}", fragment: "${e.fragment}"}`);if(e.scheme&&!t.test(e.scheme))throw new Error("[UriError]: Scheme contains illegal characters.");if(e.path)if(e.authority){if(!i.test(e.path))throw new Error('[UriError]: If a URI contains an authority component, then the path component must either be empty or begin with a slash ("/") character')}else if(s.test(e.path))throw new Error('[UriError]: If a URI does not contain an authority component, then the path cannot begin with two slash characters ("//")')}const a="",l="/",c=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/;class h{static isUri(e){return e instanceof h||!!e&&"string"==typeof e.authority&&"string"==typeof e.fragment&&"string"==typeof e.path&&"string"==typeof e.query&&"string"==typeof e.scheme&&"string"==typeof e.fsPath&&"function"==typeof e.with&&"function"==typeof e.toString}scheme;authority;path;query;fragment;constructor(e,t,n,r,i,s=!1){"object"==typeof e?(this.scheme=e.scheme||a,this.authority=e.authority||a,this.path=e.path||a,this.query=e.query||a,this.fragment=e.fragment||a):(this.scheme=function(e,t){return e||t?e:"file"}(e,s),this.authority=t||a,this.path=function(e,t){switch(e){case"https":case"http":case"file":t?t[0]!==l&&(t=l+t):t=l}return t}(this.scheme,n||a),this.query=r||a,this.fragment=i||a,o(this,s))}get fsPath(){return p(this,!1)}with(e){if(!e)return this;let{scheme:t,authority:n,path:r,query:i,fragment:s}=e;return void 0===t?t=this.scheme:null===t&&(t=a),void 0===n?n=this.authority:null===n&&(n=a),void 0===r?r=this.path:null===r&&(r=a),void 0===i?i=this.query:null===i&&(i=a),void 0===s?s=this.fragment:null===s&&(s=a),t===this.scheme&&n===this.authority&&r===this.path&&i===this.query&&s===this.fragment?this:new d(t,n,r,i,s)}static parse(e,t=!1){const n=c.exec(e);return n?new d(n[2]||a,v(n[4]||a),v(n[5]||a),v(n[7]||a),v(n[9]||a),t):new d(a,a,a,a,a)}static file(t){let n=a;if(e&&(t=t.replace(/\\/g,l)),t[0]===l&&t[1]===l){const e=t.indexOf(l,2);-1===e?(n=t.substring(2),t=l):(n=t.substring(2,e),t=t.substring(e)||l)}return new d("file",n,t,a,a)}static from(e){const t=new d(e.scheme,e.authority,e.path,e.query,e.fragment);return o(t,!0),t}toString(e=!1){return b(this,e)}toJSON(){return this}static revive(e){if(e){if(e instanceof h)return e;{const t=new d(e);return t._formatted=e.external,t._fsPath=e._sep===u?e.fsPath:null,t}}return e}}const u=e?1:void 0;class d extends h{_formatted=null;_fsPath=null;get fsPath(){return this._fsPath||(this._fsPath=p(this,!1)),this._fsPath}toString(e=!1){return e?b(this,!0):(this._formatted||(this._formatted=b(this,!1)),this._formatted)}toJSON(){const e={$mid:1};return this._fsPath&&(e.fsPath=this._fsPath,e._sep=u),this._formatted&&(e.external=this._formatted),this.path&&(e.path=this.path),this.scheme&&(e.scheme=this.scheme),this.authority&&(e.authority=this.authority),this.query&&(e.query=this.query),this.fragment&&(e.fragment=this.fragment),e}}const g={58:"%3A",47:"%2F",63:"%3F",35:"%23",91:"%5B",93:"%5D",64:"%40",33:"%21",36:"%24",38:"%26",39:"%27",40:"%28",41:"%29",42:"%2A",43:"%2B",44:"%2C",59:"%3B",61:"%3D",32:"%20"};function f(e,t,n){let r,i=-1;for(let s=0;s=97&&o<=122||o>=65&&o<=90||o>=48&&o<=57||45===o||46===o||95===o||126===o||t&&47===o||n&&91===o||n&&93===o||n&&58===o)-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),void 0!==r&&(r+=e.charAt(s));else{void 0===r&&(r=e.substr(0,s));const t=g[o];void 0!==t?(-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),r+=t):-1===i&&(i=s)}}return-1!==i&&(r+=encodeURIComponent(e.substring(i))),void 0!==r?r:e}function m(e){let t;for(let n=0;n1&&"file"===t.scheme?`//${t.authority}${t.path}`:47===t.path.charCodeAt(0)&&(t.path.charCodeAt(1)>=65&&t.path.charCodeAt(1)<=90||t.path.charCodeAt(1)>=97&&t.path.charCodeAt(1)<=122)&&58===t.path.charCodeAt(2)?n?t.path.substr(1):t.path[1].toLowerCase()+t.path.substr(2):t.path,e&&(r=r.replace(/\//g,"\\")),r}function b(e,t){const n=t?m:f;let r="",{scheme:i,authority:s,path:o,query:a,fragment:c}=e;if(i&&(r+=i,r+=":"),(s||"file"===i)&&(r+=l,r+=l),s){let e=s.indexOf("@");if(-1!==e){const t=s.substr(0,e);s=s.substr(e+1),e=t.lastIndexOf(":"),-1===e?r+=n(t,!1,!1):(r+=n(t.substr(0,e),!1,!1),r+=":",r+=n(t.substr(e+1),!1,!0)),r+="@"}s=s.toLowerCase(),e=s.lastIndexOf(":"),-1===e?r+=n(s,!1,!0):(r+=n(s.substr(0,e),!1,!0),r+=s.substr(e))}if(o){if(o.length>=3&&47===o.charCodeAt(0)&&58===o.charCodeAt(2)){const e=o.charCodeAt(1);e>=65&&e<=90&&(o=`/${String.fromCharCode(e+32)}:${o.substr(3)}`)}else if(o.length>=2&&58===o.charCodeAt(1)){const e=o.charCodeAt(0);e>=65&&e<=90&&(o=`${String.fromCharCode(e+32)}:${o.substr(2)}`)}r+=n(o,!0,!1)}return a&&(r+="?",r+=n(a,!1,!1)),c&&(r+="#",r+=t?c:f(c,!1,!1)),r}function _(e){try{return decodeURIComponent(e)}catch{return e.length>3?e.substr(0,3)+_(e.substr(3)):e}}const k=/(%[0-9A-Za-z][0-9A-Za-z])+/g;function v(e){return e.match(k)?e.replace(k,(e=>_(e))):e}var C=n(470);const y=C.posix||C,L="/";var w,S;(S=w||(w={})).joinPath=function(e,...t){return e.with({path:y.join(e.path,...t)})},S.resolvePath=function(e,...t){let n=e.path,r=!1;n[0]!==L&&(n=L+n,r=!0);let i=y.resolve(n,...t);return r&&i[0]===L&&!e.authority&&(i=i.substring(1)),e.with({path:i})},S.dirname=function(e){if(0===e.path.length||e.path===L)return e;let t=y.dirname(e.path);return 1===t.length&&46===t.charCodeAt(0)&&(t=""),e.with({path:t})},S.basename=function(e){return y.basename(e.path)},S.extname=function(e){return y.extname(e.path)}})(),gr=r})();var{URI:pr,Utils:br}=gr;function _r(e,t){if("string"!==typeof e)throw new TypeError("Expected a string");const n=String(e);let r="";const i=!!t&&!!t.extended,s=!!t&&!!t.globstar;let o=!1;const a=t&&"string"===typeof t.flags?t.flags:"";let l;for(let c=0,h=n.length;c1&&("/"===e||void 0===e||"{"===e||","===e)&&("/"===a||void 0===a||","===a||"}"===a)?("/"===a?c++:"/"===e&&r.endsWith("\\/")&&(r=r.substr(0,r.length-2)),r+="((?:[^/]*(?:/|$))*)"):r+="([^/]*)"}else r+=".*";break;default:r+=l}return a&&~a.indexOf("g")||(r="^"+r+"$"),new RegExp(r,a)}var kr,vr,Cr=class{constructor(e,t,n){this.folderUri=t,this.uris=n,this.globWrappers=[];try{for(let t of e){const e="!"!==t[0];e||(t=t.substring(1)),t.length>0&&("/"===t[0]&&(t=t.substring(1)),this.globWrappers.push({regexp:_r("**/"+t,{extended:!0,globstar:!0}),include:e}))}t&&((t=Nr(t)).endsWith("/")||(t+="/"),this.folderUri=t)}catch(r){this.globWrappers.length=0,this.uris=[]}}matchesPattern(e){if(this.folderUri&&!e.startsWith(this.folderUri))return!1;let t=!1;for(const{regexp:n,include:r}of this.globWrappers)n.test(e)&&(t=r);return t}getURIs(){return this.uris}},yr=class{constructor(e,t,n){this.service=e,this.uri=t,this.dependencies=new Set,this.anchors=void 0,n&&(this.unresolvedSchema=this.service.promise.resolve(new Lr(n)))}getUnresolvedSchema(){return this.unresolvedSchema||(this.unresolvedSchema=this.service.loadSchema(this.uri)),this.unresolvedSchema}getResolvedSchema(){return this.resolvedSchema||(this.resolvedSchema=this.getUnresolvedSchema().then((e=>this.service.resolveSchemaContent(e,this)))),this.resolvedSchema}clearSchema(){const e=!!this.unresolvedSchema;return this.resolvedSchema=void 0,this.unresolvedSchema=void 0,this.dependencies.clear(),this.anchors=void 0,e}},Lr=class{constructor(e,t=[]){this.schema=e,this.errors=t}},wr=class{constructor(e,t=[],n=[],r){this.schema=e,this.errors=t,this.warnings=n,this.schemaDraft=r}getSection(e){const t=this.getSectionRecursive(e,this.schema);if(t)return zn(t)}getSectionRecursive(e,t){if(!t||"boolean"===typeof t||0===e.length)return t;const n=e.shift();if(t.properties&&(t.properties[n],1))return this.getSectionRecursive(e,t.properties[n]);if(t.patternProperties)for(const r of Object.keys(t.patternProperties)){const i=hn(r);if(i?.test(n))return this.getSectionRecursive(e,t.patternProperties[r])}else{if("object"===typeof t.additionalProperties)return this.getSectionRecursive(e,t.additionalProperties);if(n.match("[0-9]+"))if(Array.isArray(t.items)){const r=parseInt(n,10);if(!isNaN(r)&&t.items[r])return this.getSectionRecursive(e,t.items[r])}else if(t.items)return this.getSectionRecursive(e,t.items)}}},Sr=class{constructor(e,t,n){this.contextService=t,this.requestService=e,this.promiseConstructor=n||Promise,this.callOnDispose=[],this.contributionSchemas={},this.contributionAssociations=[],this.schemasById={},this.filePatternAssociations=[],this.registeredSchemasIds={}}getRegisteredSchemaIds(e){return Object.keys(this.registeredSchemasIds).filter((t=>{const n=pr.parse(t).scheme;return"schemaservice"!==n&&(!e||e(n))}))}get promise(){return this.promiseConstructor}dispose(){for(;this.callOnDispose.length>0;)this.callOnDispose.pop()()}onResourceChange(e){this.cachedSchemaForResource=void 0;let t=!1;const n=[e=Er(e)],r=Object.keys(this.schemasById).map((e=>this.schemasById[e]));for(;n.length;){const e=n.pop();for(let i=0;i{if(!t){const t=xn("Unable to load schema from '{0}': No content.",Tr(e));return new Lr({},[t])}const n=[];65279===t.charCodeAt(0)&&(n.push(xn("Problem reading content from '{0}': UTF-8 with BOM detected, only UTF 8 is allowed.",Tr(e))),t=t.trimStart());let r={};const i=[];return r=Yt(t,i),i.length&&n.push(xn("Unable to parse content from '{0}': Parse error at offset {1}.",Tr(e),i[0].offset)),new Lr(r,n)}),(t=>{let n=t.toString();const r=t.toString().split("Error: ");return r.length>1&&(n=r[1]),cn(n,".")&&(n=n.substr(0,n.length-1)),new Lr({},[xn("Unable to load schema from '{0}': {1}.",Tr(e),n)])}))}resolveSchemaContent(e,t){const n=e.errors.slice(0),r=e.schema;let i=r.$schema?Er(r.$schema):void 0;if("http://json-schema.org/draft-03/schema"===i)return this.promise.resolve(new wr({},[xn("Draft-03 schemas are not supported.")],[],i));let s=new Set;const o=this.contextService,a=(e,t,r,i)=>{let s;var o,a,l;void 0===i||0===i.length?s=t:"/"===i.charAt(0)?s=((e,t)=>{t=decodeURIComponent(t);let n=e;return"/"===t[0]&&(t=t.substring(1)),t.split("/").some((e=>(e=e.replace(/~1/g,"/").replace(/~0/g,"~"),n=n[e],!n))),n})(t,i):(o=t,l=i,(a=r).anchors||(a.anchors=h(o)),s=a.anchors.get(l)),s?((e,t)=>{for(const n in t)t.hasOwnProperty(n)&&"id"!==n&&"$id"!==n&&(e[n]=t[n])})(e,s):n.push(xn("$ref '{0}' in '{1}' can not be resolved.",i||"",r.uri))},l=(e,t,r,i)=>{o&&!/^[A-Za-z][A-Za-z0-9+\-.+]*:\/\/.*/.test(t)&&(t=o.resolveRelativePath(t,i.uri)),t=Er(t);const s=this.getOrAddSchemaHandle(t);return s.getUnresolvedSchema().then((o=>{if(i.dependencies.add(t),o.errors.length){const e=r?t+"#"+r:t;n.push(xn("Problems loading reference '{0}': {1}",e,o.errors[0]))}return a(e,o.schema,s,r),c(e,o.schema,s)}))},c=(e,t,n)=>{const r=[];return this.traverseNodes(e,(e=>{const i=new Set;for(;e.$ref;){const s=e.$ref,o=s.split("#",2);if(delete e.$ref,o[0].length>0)return void r.push(l(e,o[0],o[1],n));if(!i.has(s)){const r=o[1];a(e,t,n,r),i.add(s)}}e.$recursiveRef&&s.add("$recursiveRef"),e.$dynamicRef&&s.add("$dynamicRef")})),this.promise.all(r)},h=e=>{const t=new Map;return this.traverseNodes(e,(e=>{const r=e.$id||e.id,i=an(r)&&"#"===r.charAt(0)?r.substring(1):e.$anchor;i&&(t.has(i)?n.push(xn("Duplicate anchor declaration: '{0}'",i)):t.set(i,e)),e.$recursiveAnchor&&s.add("$recursiveAnchor"),e.$dynamicAnchor&&s.add("$dynamicAnchor")})),t};return c(r,r,t).then((e=>{let t=[];return s.size&&t.push(xn("The schema uses meta-schema features ({0}) that are not yet supported by the validator.",Array.from(s.keys()).join(", "))),new wr(r,n,t,i)}))}traverseNodes(e,t){if(!e||"object"!==typeof e)return Promise.resolve(null);const n=new Set,r=(...e)=>{for(const t of e)ln(t)&&a.push(t)},i=(...e)=>{for(const t of e)if(ln(t))for(const e in t){const n=t[e];ln(n)&&a.push(n)}},s=(...e)=>{for(const t of e)if(Array.isArray(t))for(const e of t)ln(e)&&a.push(e)},o=e=>{if(Array.isArray(e))for(const t of e)ln(t)&&a.push(t);else ln(e)&&a.push(e)},a=[e];let l=a.pop();for(;l;)n.has(l)||(n.add(l),t(l),r(l.additionalItems,l.additionalProperties,l.not,l.contains,l.propertyNames,l.if,l.then,l.else,l.unevaluatedItems,l.unevaluatedProperties),i(l.definitions,l.$defs,l.properties,l.patternProperties,l.dependencies,l.dependentSchemas),s(l.anyOf,l.allOf,l.oneOf,l.prefixItems),o(l.items)),l=a.pop()}getSchemaFromProperty(e,t){if("object"===t.root?.type)for(const n of t.root.properties)if("$schema"===n.keyNode.value&&"string"===n.valueNode?.type){let t=n.valueNode.value;return this.contextService&&!/^\w[\w\d+.-]*:/.test(t)&&(t=this.contextService.resolveRelativePath(t,e)),t}}getAssociatedSchemas(e){const t=Object.create(null),n=[],r=Nr(e);for(const i of this.filePatternAssociations)if(i.matchesPattern(r))for(const e of i.getURIs())t[e]||(n.push(e),t[e]=!0);return n}getSchemaURIsForResource(e,t){let n=t&&this.getSchemaFromProperty(e,t);return n?[n]:this.getAssociatedSchemas(e)}getSchemaForResource(e,t){if(t){let n=this.getSchemaFromProperty(e,t);if(n){const e=Er(n);return this.getOrAddSchemaHandle(e).getResolvedSchema()}}if(this.cachedSchemaForResource&&this.cachedSchemaForResource.resource===e)return this.cachedSchemaForResource.resolvedSchema;const n=this.getAssociatedSchemas(e),r=n.length>0?this.createCombinedSchema(e,n).getResolvedSchema():this.promise.resolve(void 0);return this.cachedSchemaForResource={resource:e,resolvedSchema:r},r}createCombinedSchema(e,t){if(1===t.length)return this.getOrAddSchemaHandle(t[0]);{const n="schemaservice://combinedSchema/"+encodeURIComponent(e),r={allOf:t.map((e=>({$ref:e})))};return this.addSchemaHandle(n,r)}}getMatchingSchemas(e,t,n){if(n){const e=n.id||"schemaservice://untitled/matchingSchemas/"+xr++;return this.addSchemaHandle(e,n).getResolvedSchema().then((e=>t.getMatchingSchemas(e.schema).filter((e=>!e.inverted))))}return this.getSchemaForResource(e.uri,t).then((e=>e?t.getMatchingSchemas(e.schema).filter((e=>!e.inverted)):[]))}},xr=0;function Er(e){try{return pr.parse(e).toString(!0)}catch(t){return e}}function Nr(e){try{return pr.parse(e).with({fragment:null,query:null}).toString(!0)}catch(t){return e}}function Tr(e){try{const t=pr.parse(e);if("file"===t.scheme)return t.fsPath}catch(t){}return e}function Ar(e,t){const n=[],r=[],i=[];let s=-1;const o=w(e.getText(),!1);let a=o.scan();function l(e){n.push(e),r.push(i.length)}for(;17!==a;){switch(a){case 1:case 3:{const t=e.positionAt(o.getTokenOffset()).line,n={startLine:t,endLine:t,kind:1===a?"object":"array"};i.push(n);break}case 2:case 4:{const t=2===a?"object":"array";if(i.length>0&&i[i.length-1].kind===t){const t=i.pop(),n=e.positionAt(o.getTokenOffset()).line;t&&n>t.startLine+1&&s!==t.startLine&&(t.endLine=n-1,l(t),s=t.startLine)}break}case 13:{const t=e.positionAt(o.getTokenOffset()).line,n=e.positionAt(o.getTokenOffset()+o.getTokenLength()).line;1===o.getTokenError()&&t+1=0&&i[e].kind!==K.Region;)e--;if(e>=0){const t=i[e];i.length=e,n>t.startLine&&s!==t.startLine&&(t.endLine=n,l(t),s=t.startLine)}}}break}}a=o.scan()}const c=t&&t.rangeLimit;if("number"!==typeof c||n.length<=c)return n;t&&t.onRangeLimitExceeded&&t.onRangeLimitExceeded(e.uri);const h=[];for(let f of r)f<30&&(h[f]=(h[f]||0)+1);let u=0,d=0;for(let f=0;fc){d=f;break}u+=e}}const g=[];for(let f=0;f=e&&i<=t&&a.push(r(e,t)),a.push(r(o.offset,o.offset+o.length));break;case"number":case"boolean":case"null":case"property":a.push(r(o.offset,o.offset+o.length))}if("property"===o.type||o.parent&&"array"===o.parent.type){const e=s(o.offset+o.length,5);-1!==e&&a.push(r(o.offset,e))}o=o.parent}let l;for(let e=a.length-1;e>=0;e--)l=yt.create(a[e],l);return l||(l=yt.create(D.create(t,t))),l}))}function Or(e,t,n){let r;if(n){const t=e.offsetAt(n.start);r={offset:t,length:e.offsetAt(n.end)-t}}const i={tabSize:t?t.tabSize:4,insertSpaces:!0===t?.insertSpaces,insertFinalNewline:!0===t?.insertFinalNewline,eol:"\n",keepLines:!0===t?.keepLines};return function(e,t,n){return b(e,t,n)}(e.getText(),r,i).map((t=>le.replace(D.create(e.positionAt(t.offset),e.positionAt(t.offset+t.length)),t.content)))}(vr=kr||(kr={}))[vr.Object=0]="Object",vr[vr.Array=1]="Array";var Mr=class{constructor(e,t){this.propertyName=e??"",this.beginningLineNumber=t,this.childrenProperties=[],this.lastProperty=!1,this.noKeyName=!1}addChildProperty(e){if(e.parent=this,this.childrenProperties.length>0){let t=0;t=e.noKeyName?this.childrenProperties.length:function(e,t,n){const r=t.propertyName.toLowerCase(),i=e[0].propertyName.toLowerCase(),s=e[e.length-1].propertyName.toLowerCase();if(rs)return e.length;let o=0,a=e.length-1;for(;o<=a;){let r=a+o>>1,i=n(t,e[r]);if(i>0)o=r+1;else{if(!(i<0))return r;a=r-1}}return-o-1}(this.childrenProperties,e,Rr),t<0&&(t=-1*t-1),this.childrenProperties.splice(t,0,e)}else this.childrenProperties.push(e);return e}};function Rr(e,t){const n=e.propertyName.toLowerCase(),r=t.propertyName.toLowerCase();return nr?1:0}function Dr(e,t){const n={...t,keepLines:!1},r=fn.applyEdits(e,Or(e,n,void 0)),i=fn.create("test://test.json","json",0,r),s=function(e,t){if(0===t.childrenProperties.length)return e;const n=fn.create("test://test.json","json",0,e.getText()),r=[];Br(r,t,t.beginningLineNumber);for(;r.length>0;){const t=r.shift(),i=t.propertyTreeArray;let s=t.beginningLineNumber;for(let o=0;o{if("property"===r.type&&"$ref"===r.keyNode.value&&"string"===r.valueNode?.type){const i=r.valueNode.value,s=function(e,t){const n=function(e){if("#"===e)return[];if("#"!==e[0]||"/"!==e[1])return null;return e.substring(2).split(/\//).map(Wr)}(t);if(!n)return null;return qr(n,e.root)}(t,i);if(s){const t=e.positionAt(s.offset);n.push({target:`${e.uri}#${t.line+1},${t.character+1}`,range:jr(e,r.valueNode)})}}return!0})),Promise.resolve(n)}function jr(e,t){return D.create(e.positionAt(t.offset+1),e.positionAt(t.offset+t.length-1))}function qr(e,t){if(!t)return null;if(0===e.length)return t;const n=e.shift();if(t&&"object"===t.type){const r=t.properties.find((e=>e.keyNode.value===n));return r?qr(e,r.valueNode):null}if(t&&"array"===t.type&&n.match(/^(0|[1-9][0-9]*)$/)){const r=Number.parseInt(n),i=t.items[r];return i?qr(e,i):null}return null}function Wr(e){return e.replace(/~1/g,"/").replace(/~0/g,"~")}function Ur(e){const t=e.promiseConstructor||Promise,n=new Sr(e.schemaRequestService,e.workspaceContext,t);n.setSchemaContributions(fr);const r=new er(n,e.contributions,t,e.clientCapabilities),i=new tr(n,e.contributions,t),s=new hr(n),o=new rr(n,t);return{configure:e=>{n.clearExternalSchemas(),e.schemas?.forEach(n.registerExternalSchema.bind(n)),o.configure(e)},resetSchema:e=>n.onResourceChange(e),doValidation:o.doValidation.bind(o),getLanguageStatus:o.getLanguageStatus.bind(o),parseJSONDocument:e=>Yn(e,{collectComments:!0}),newJSONDocument:(e,t)=>function(e,t=[]){return new Qn(e,t,[])}(e,t),getMatchingSchemas:n.getMatchingSchemas.bind(n),doResolve:r.doResolve.bind(r),doComplete:r.doComplete.bind(r),findDocumentSymbols:s.findDocumentSymbols.bind(s),findDocumentSymbols2:s.findDocumentSymbols2.bind(s),findDocumentColors:s.findDocumentColors.bind(s),getColorPresentations:s.getColorPresentations.bind(s),doHover:i.doHover.bind(i),getFoldingRanges:Ar,getSelectionRanges:Ir,findDefinition:()=>Promise.resolve([]),findLinks:zr,format:(e,t,n)=>Or(e,n,t),sort:(e,t)=>Dr(e,t)}}"undefined"!==typeof fetch&&(Pr=function(e){return fetch(e).then((e=>e.text()))});var $r=class{constructor(e,t){this._ctx=e,this._languageSettings=t.languageSettings,this._languageId=t.languageId,this._languageService=Ur({workspaceContext:{resolveRelativePath:(e,t)=>function(e,t){if(function(e){return e.charCodeAt(0)===Hr}(t)){const n=pr.parse(e),r=t.split("/");return n.with({path:Gr(r)}).toString()}return function(e,...t){const n=pr.parse(e),r=n.path.split("/");for(let i of t)r.push(...i.split("/"));return n.with({path:Gr(r)}).toString()}(e,t)}(t.substr(0,t.lastIndexOf("/")+1),e)},schemaRequestService:t.enableSchemaRequest?Pr:void 0,clientCapabilities:vn.LATEST}),this._languageService.configure(this._languageSettings)}async doValidation(e){let t=this._getTextDocument(e);if(t){let e=this._languageService.parseJSONDocument(t);return this._languageService.doValidation(t,e,this._languageSettings)}return Promise.resolve([])}async doComplete(e,t){let n=this._getTextDocument(e);if(!n)return null;let r=this._languageService.parseJSONDocument(n);return this._languageService.doComplete(n,t,r)}async doResolve(e){return this._languageService.doResolve(e)}async doHover(e,t){let n=this._getTextDocument(e);if(!n)return null;let r=this._languageService.parseJSONDocument(n);return this._languageService.doHover(n,t,r)}async format(e,t,n){let r=this._getTextDocument(e);if(!r)return[];let i=this._languageService.format(r,t,n);return Promise.resolve(i)}async resetSchema(e){return Promise.resolve(this._languageService.resetSchema(e))}async findDocumentSymbols(e){let t=this._getTextDocument(e);if(!t)return[];let n=this._languageService.parseJSONDocument(t),r=this._languageService.findDocumentSymbols2(t,n);return Promise.resolve(r)}async findDocumentColors(e){let t=this._getTextDocument(e);if(!t)return[];let n=this._languageService.parseJSONDocument(t),r=this._languageService.findDocumentColors(t,n);return Promise.resolve(r)}async getColorPresentations(e,t,n){let r=this._getTextDocument(e);if(!r)return[];let i=this._languageService.parseJSONDocument(r),s=this._languageService.getColorPresentations(r,i,t,n);return Promise.resolve(s)}async getFoldingRanges(e,t){let n=this._getTextDocument(e);if(!n)return[];let r=this._languageService.getFoldingRanges(n,t);return Promise.resolve(r)}async getSelectionRanges(e,t){let n=this._getTextDocument(e);if(!n)return[];let r=this._languageService.parseJSONDocument(n),i=this._languageService.getSelectionRanges(n,t,r);return Promise.resolve(i)}async parseJSONDocument(e){let t=this._getTextDocument(e);if(!t)return null;let n=this._languageService.parseJSONDocument(t);return Promise.resolve(n)}async getMatchingSchemas(e){let t=this._getTextDocument(e);if(!t)return[];let n=this._languageService.parseJSONDocument(t);return Promise.resolve(this._languageService.getMatchingSchemas(t,n))}_getTextDocument(e){let t=this._ctx.getMirrorModels();for(let n of t)if(n.uri.toString()===e)return fn.create(e,this._languageId,n.version,n.getValue());return null}},Hr="/".charCodeAt(0),Kr=".".charCodeAt(0);function Gr(e){const t=[];for(const r of e)0===r.length||1===r.length&&r.charCodeAt(0)===Kr||(2===r.length&&r.charCodeAt(0)===Kr&&r.charCodeAt(1)===Kr?t.pop():t.push(r));e.length>1&&0===e[e.length-1].length&&t.push("");let n=t.join("/");return 0===e[0].length&&(n="/"+n),n}self.onmessage=()=>{s(((e,t)=>new $r(e,t)))}})()})(); \ No newline at end of file +(()=>{var e={146:(e,t,n)=>{"use strict";n.d(t,{V0:()=>i,aI:()=>r,kT:()=>s});Object.prototype.hasOwnProperty;function r(e,t){if(e===t)return!0;if(null===e||void 0===e||null===t||void 0===t)return!1;if(typeof e!==typeof t)return!1;if("object"!==typeof e)return!1;if(Array.isArray(e)!==Array.isArray(t))return!1;let n,i;if(Array.isArray(e)){if(e.length!==t.length)return!1;for(n=0;nfunction(){const n=Array.prototype.slice.call(arguments,0);return t(e,n)},r={};for(const i of e)r[i]=n(i);return r}},154:(e,t,n)=>{"use strict";n.d(t,{L:()=>r});const r=(0,n(3591).u1)("languageService")},360:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITextResourceConfigurationService:()=>i,ITextResourcePropertiesService:()=>s});var r=n(3591);const i=(0,r.u1)("textResourceConfigurationService"),s=(0,r.u1)("textResourcePropertiesService")},448:(e,t,n)=>{"use strict";n.r(t),n.d(t,{MarkerDecorationsService:()=>L});var r,i=n(1508);!function(e){e[e.Ignore=0]="Ignore",e[e.Info=1]="Info",e[e.Warning=2]="Warning",e[e.Error=3]="Error"}(r||(r={})),function(e){const t="error",n="warning",r="info";e.fromValue=function(s){return s?i.Q_(t,s)?e.Error:i.Q_(n,s)||i.Q_("warn",s)?e.Warning:i.Q_(r,s)?e.Info:e.Ignore:e.Ignore},e.toString=function(i){switch(i){case e.Error:return t;case e.Warning:return n;case e.Info:return r;default:return"ignore"}}}(r||(r={}));const s=r;var o,a,l=n(8209),c=n(3591);!function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(o||(o={})),function(e){e.compare=function(e,t){return t-e};const t=Object.create(null);t[e.Error]=(0,l.kg)("sev.error","Error"),t[e.Warning]=(0,l.kg)("sev.warning","Warning"),t[e.Info]=(0,l.kg)("sev.info","Info"),e.toString=function(e){return t[e]||""},e.fromSeverity=function(t){switch(t){case s.Error:return e.Error;case s.Warning:return e.Warning;case s.Info:return e.Info;case s.Ignore:return e.Hint}},e.toSeverity=function(t){switch(t){case e.Error:return s.Error;case e.Warning:return s.Warning;case e.Info:return s.Info;case e.Hint:return s.Ignore}}}(o||(o={})),function(e){const t="";function n(e,n){const r=[t];return e.source?r.push(e.source.replace("\xa6","\\\xa6")):r.push(t),e.code?"string"===typeof e.code?r.push(e.code.replace("\xa6","\\\xa6")):r.push(e.code.value.replace("\xa6","\\\xa6")):r.push(t),void 0!==e.severity&&null!==e.severity?r.push(o.toString(e.severity)):r.push(t),e.message&&n?r.push(e.message.replace("\xa6","\\\xa6")):r.push(t),void 0!==e.startLineNumber&&null!==e.startLineNumber?r.push(e.startLineNumber.toString()):r.push(t),void 0!==e.startColumn&&null!==e.startColumn?r.push(e.startColumn.toString()):r.push(t),void 0!==e.endLineNumber&&null!==e.endLineNumber?r.push(e.endLineNumber.toString()):r.push(t),void 0!==e.endColumn&&null!==e.endColumn?r.push(e.endColumn.toString()):r.push(t),r.push(t),r.join("\xa6")}e.makeKey=function(e){return n(e,!0)},e.makeKeyOptionalMessage=n}(a||(a={}));const h=(0,c.u1)("markerService");var u=n(1484),d=n(6223),g=n(5724),f=n(7119),m=n(3750),p=n(6677),b=n(6456),_=n(1234),k=n(5845),v=n(4320);var C=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},y=function(e,t){return function(n,r){t(n,r,e)}};let L=class extends u.jG{constructor(e,t){super(),this._markerService=t,this._onDidChangeMarker=this._register(new _.vl),this._markerDecorations=new v.fT,e.getModels().forEach((e=>this._onModelAdded(e))),this._register(e.onModelAdded(this._onModelAdded,this)),this._register(e.onModelRemoved(this._onModelRemoved,this)),this._register(this._markerService.onMarkerChanged(this._handleMarkerChange,this))}dispose(){super.dispose(),this._markerDecorations.forEach((e=>e.dispose())),this._markerDecorations.clear()}getMarker(e,t){const n=this._markerDecorations.get(e);return n&&n.getMarker(t)||null}_handleMarkerChange(e){e.forEach((e=>{const t=this._markerDecorations.get(e);t&&this._updateDecorations(t)}))}_onModelAdded(e){const t=new w(e);this._markerDecorations.set(e.uri,t),this._updateDecorations(t)}_onModelRemoved(e){const t=this._markerDecorations.get(e.uri);t&&(t.dispose(),this._markerDecorations.delete(e.uri)),e.uri.scheme!==b.ny.inMemory&&e.uri.scheme!==b.ny.internal&&e.uri.scheme!==b.ny.vscode||this._markerService?.read({resource:e.uri}).map((e=>e.owner)).forEach((t=>this._markerService.remove(t,[e.uri])))}_updateDecorations(e){const t=this._markerService.read({resource:e.model.uri,take:500});e.update(t)&&this._onDidChangeMarker.fire(e.model)}};L=C([y(0,m.IModelService),y(1,h)],L);class w extends u.jG{constructor(e){super(),this.model=e,this._map=new v.cO,this._register((0,u.s)((()=>{this.model.deltaDecorations([...this._map.values()],[]),this._map.clear()})))}update(e){const{added:t,removed:n}=function(e,t){const n=[],r=[];for(const i of e)t.has(i)||n.push(i);for(const i of t)e.has(i)||r.push(i);return{removed:n,added:r}}(new Set(this._map.keys()),new Set(e));if(0===t.length&&0===n.length)return!1;const r=n.map((e=>this._map.get(e))),i=t.map((e=>({range:this._createDecorationRange(this.model,e),options:this._createDecorationOption(e)}))),s=this.model.deltaDecorations(r,i);for(const o of n)this._map.delete(o);for(let o=0;o=t)return n;const r=e.getWordAtPosition(n.getStartPosition());r&&(n=new p.Q(n.startLineNumber,r.startColumn,n.endLineNumber,r.endColumn))}else if(t.endColumn===Number.MAX_VALUE&&1===t.startColumn&&n.startLineNumber===n.endLineNumber){const r=e.getLineFirstNonWhitespaceColumn(t.startLineNumber);r=0}}},534:(e,t,n)=>{"use strict";n.d(t,{V:()=>i});var r=n(5152);class i{constructor(e){const t=(0,r.W)(e);this._defaultValue=t,this._asciiMap=i._createAsciiMap(t),this._map=new Map}static _createAsciiMap(e){const t=new Uint8Array(256);return t.fill(e),t}set(e,t){const n=(0,r.W)(t);e>=0&&e<256?this._asciiMap[e]=n:this._map.set(e,n)}get(e){return e>=0&&e<256?this._asciiMap[e]:this._map.get(e)||this._defaultValue}clear(){this._asciiMap.fill(this._defaultValue),this._map.clear()}}},631:(e,t,n)=>{"use strict";function r(e){return"string"===typeof e}function i(e){return"object"===typeof e&&null!==e&&!Array.isArray(e)&&!(e instanceof RegExp)&&!(e instanceof Date)}function s(e){return"undefined"===typeof e}function o(e){return s(e)||null===e}n.d(t,{Gv:()=>i,Kg:()=>r,b0:()=>s,z:()=>o})},718:(e,t,n)=>{"use strict";n.r(t),n.d(t,{EditorWorkerHost:()=>r});class r{static{this.CHANNEL_NAME="editorWorkerHost"}static getChannel(e){return e.getChannel(r.CHANNEL_NAME)}static setChannel(e,t){e.setChannel(r.CHANNEL_NAME,t)}}},796:(e,t,n)=>{"use strict";n.r(t),n.d(t,{MirrorModel:()=>b,STOP_SYNC_MODEL_DELTA_TIME_MS:()=>f,WorkerTextModelSyncClient:()=>m,WorkerTextModelSyncServer:()=>p});var r=n(1940),i=n(1484),s=n(9400),o=n(3069),a=n(6677),l=n(6486),c=n(1508),h=(n(9861),n(5152));class u{constructor(e){this.values=e,this.prefixSum=new Uint32Array(e.length),this.prefixSumValidIndex=new Int32Array(1),this.prefixSumValidIndex[0]=-1}insertValues(e,t){e=(0,h.j)(e);const n=this.values,r=this.prefixSum,i=t.length;return 0!==i&&(this.values=new Uint32Array(n.length+i),this.values.set(n.subarray(0,e),0),this.values.set(n.subarray(e),e+i),this.values.set(t,e),e-1=0&&this.prefixSum.set(r.subarray(0,this.prefixSumValidIndex[0]+1)),!0)}setValue(e,t){return e=(0,h.j)(e),t=(0,h.j)(t),this.values[e]!==t&&(this.values[e]=t,e-1=n.length)return!1;const i=n.length-e;return t>=i&&(t=i),0!==t&&(this.values=new Uint32Array(n.length-t),this.values.set(n.subarray(0,e),0),this.values.set(n.subarray(e+t),e),this.prefixSum=new Uint32Array(this.values.length),e-1=0&&this.prefixSum.set(r.subarray(0,this.prefixSumValidIndex[0]+1)),!0)}getTotalSum(){return 0===this.values.length?0:this._getPrefixSum(this.values.length-1)}getPrefixSum(e){return e<0?0:(e=(0,h.j)(e),this._getPrefixSum(e))}_getPrefixSum(e){if(e<=this.prefixSumValidIndex[0])return this.prefixSum[e];let t=this.prefixSumValidIndex[0]+1;0===t&&(this.prefixSum[0]=this.values[0],t++),e>=this.values.length&&(e=this.values.length-1);for(let n=t;n<=e;n++)this.prefixSum[n]=this.prefixSum[n-1]+this.values[n];return this.prefixSumValidIndex[0]=Math.max(this.prefixSumValidIndex[0],e),this.prefixSum[e]}getIndexOf(e){e=Math.floor(e),this.getTotalSum();let t=0,n=this.values.length-1,r=0,i=0,s=0;for(;t<=n;)if(r=t+(n-t)/2|0,i=this.prefixSum[r],s=i-this.values[r],e=i))break;t=r+1}return new d(r,e-s)}}class d{constructor(e,t){this.index=e,this.remainder=t,this._prefixSumIndexOfResultBrand=void 0,this.index=e,this.remainder=t}}class g{constructor(e,t,n,r){this._uri=e,this._lines=t,this._eol=n,this._versionId=r,this._lineStarts=null,this._cachedTextValue=null}dispose(){this._lines.length=0}get version(){return this._versionId}getText(){return null===this._cachedTextValue&&(this._cachedTextValue=this._lines.join(this._eol)),this._cachedTextValue}onEvents(e){e.eol&&e.eol!==this._eol&&(this._eol=e.eol,this._lineStarts=null);const t=e.changes;for(const n of t)this._acceptDeleteRange(n.range),this._acceptInsertText(new o.y(n.range.startLineNumber,n.range.startColumn),n.text);this._versionId=e.versionId,this._cachedTextValue=null}_ensureLineStarts(){if(!this._lineStarts){const e=this._eol.length,t=this._lines.length,n=new Uint32Array(t);for(let r=0;rthis._checkStopModelSync()),Math.round(f/2)),this._register(e)}}dispose(){for(const e in this._syncedModels)(0,i.AS)(this._syncedModels[e]);this._syncedModels=Object.create(null),this._syncedModelsLastUsedTime=Object.create(null),super.dispose()}ensureSyncedResources(e,t=!1){for(const n of e){const e=n.toString();this._syncedModels[e]||this._beginModelSync(n,t),this._syncedModels[e]&&(this._syncedModelsLastUsedTime[e]=(new Date).getTime())}}_checkStopModelSync(){const e=(new Date).getTime(),t=[];for(const n in this._syncedModelsLastUsedTime){e-this._syncedModelsLastUsedTime[n]>f&&t.push(n)}for(const n of t)this._stopModelSync(n)}_beginModelSync(e,t){const n=this._modelService.getModel(e);if(!n)return;if(!t&&n.isTooLargeForSyncing())return;const r=e.toString();this._proxy.$acceptNewModel({url:n.uri.toString(),lines:n.getLinesContent(),EOL:n.getEOL(),versionId:n.getVersionId()});const s=new i.Cm;s.add(n.onDidChangeContent((e=>{this._proxy.$acceptModelChanged(r.toString(),e)}))),s.add(n.onWillDispose((()=>{this._stopModelSync(r)}))),s.add((0,i.s)((()=>{this._proxy.$acceptRemovedModel(r)}))),this._syncedModels[r]=s}_stopModelSync(e){const t=this._syncedModels[e];delete this._syncedModels[e],delete this._syncedModelsLastUsedTime[e],(0,i.AS)(t)}}class p{constructor(){this._models=Object.create(null)}getModel(e){return this._models[e]}getModels(){const e=[];return Object.keys(this._models).forEach((t=>e.push(this._models[t]))),e}$acceptNewModel(e){this._models[e.url]=new b(s.r.parse(e.url),e.lines,e.EOL,e.versionId)}$acceptModelChanged(e,t){if(!this._models[e])return;this._models[e].onEvents(t)}$acceptRemovedModel(e){this._models[e]&&delete this._models[e]}}class b extends g{get uri(){return this._uri}get eol(){return this._eol}getValue(){return this.getText()}findMatches(e){const t=[];for(let n=0;nthis._lines.length)t=this._lines.length,n=this._lines[t-1].length+1,r=!0;else{const e=this._lines[t-1].length+1;n<1?(n=1,r=!0):n>e&&(n=e,r=!0)}return r?{lineNumber:t,column:n}:e}}},920:(e,t,n)=>{"use strict";n.r(t),n.d(t,{IEditorWorkerService:()=>r});const r=(0,n(3591).u1)("editorWorkerService")},973:(e,t,n)=>{"use strict";n.d(t,{W:()=>s});var r=n(3069),i=n(6677);class s{static{this.zero=new s(0,0)}static betweenPositions(e,t){return e.lineNumber===t.lineNumber?new s(0,t.column-e.column):new s(t.lineNumber-e.lineNumber,t.column-1)}static ofRange(e){return s.betweenPositions(e.getStartPosition(),e.getEndPosition())}static ofText(e){let t=0,n=0;for(const r of e)"\n"===r?(t++,n=0):n++;return new s(t,n)}constructor(e,t){this.lineCount=e,this.columnCount=t}isGreaterThanOrEqualTo(e){return this.lineCount!==e.lineCount?this.lineCount>e.lineCount:this.columnCount>=e.columnCount}createRange(e){return 0===this.lineCount?new i.Q(e.lineNumber,e.column,e.lineNumber,e.column+this.columnCount):new i.Q(e.lineNumber,e.column,e.lineNumber+this.lineCount,this.columnCount+1)}addToPosition(e){return 0===this.lineCount?new r.y(e.lineNumber,e.column+this.columnCount):new r.y(e.lineNumber+this.lineCount,this.columnCount+1)}toString(){return`${this.lineCount},${this.columnCount}`}}},1090:(e,t,n)=>{"use strict";n.d(t,{d:()=>r});class r{constructor(e){this.executor=e,this._didRun=!1}get value(){if(!this._didRun)try{this._value=this.executor()}catch(e){this._error=e}finally{this._didRun=!0}if(this._error)throw this._error;return this._value}get rawValue(){return this._value}}},1234:(e,t,n)=>{"use strict";n.d(t,{Jh:()=>o,vl:()=>f});var r=n(4383),i=n(1484),s=(n(8925),n(8381));var o;!function(e){function t(e){false}function n(e){return(t,n=null,r)=>{let i,s=!1;return i=e((e=>{if(!s)return i?i.dispose():s=!0,t.call(n,e)}),null,r),s&&i.dispose(),i}}function r(e,t,n){return o(((n,r=null,i)=>e((e=>n.call(r,t(e))),null,i)),n)}function s(e,t,n){return o(((n,r=null,i)=>e((e=>t(e)&&n.call(r,e)),null,i)),n)}function o(e,n){let r;const i={onWillAddFirstListener(){r=e(s.fire,s)},onDidRemoveLastListener(){r?.dispose()}};n||t();const s=new f(i);return n?.add(s),s.event}function a(e,n,r=100,i=!1,s=!1,o,a){let l,c,h,u,d=0;const g={leakWarningThreshold:o,onWillAddFirstListener(){l=e((e=>{d++,c=n(c,e),i&&!h&&(m.fire(c),c=void 0),u=()=>{const e=c;c=void 0,h=void 0,(!i||d>1)&&m.fire(e),d=0},"number"===typeof r?(clearTimeout(h),h=setTimeout(u,r)):void 0===h&&(h=0,queueMicrotask(u))}))},onWillRemoveListener(){s&&d>0&&u?.()},onDidRemoveLastListener(){u=void 0,l.dispose()}};a||t();const m=new f(g);return a?.add(m),m.event}e.None=()=>i.jG.None,e.defer=function(e,t){return a(e,(()=>{}),0,void 0,!0,void 0,t)},e.once=n,e.onceIf=function(t,n){return e.once(e.filter(t,n))},e.map=r,e.forEach=function(e,t,n){return o(((n,r=null,i)=>e((e=>{t(e),n.call(r,e)}),null,i)),n)},e.filter=s,e.signal=function(e){return e},e.any=function(...e){return(t,n=null,r)=>function(e,t){t instanceof Array?t.push(e):t&&t.add(e);return e}((0,i.qE)(...e.map((e=>e((e=>t.call(n,e)))))),r)},e.reduce=function(e,t,n,i){let s=n;return r(e,(e=>(s=t(s,e),s)),i)},e.debounce=a,e.accumulate=function(t,n=0,r){return e.debounce(t,((e,t)=>e?(e.push(t),e):[t]),n,void 0,!0,void 0,r)},e.latch=function(e,t=(e,t)=>e===t,n){let r,i=!0;return s(e,(e=>{const n=i||!t(e,r);return i=!1,r=e,n}),n)},e.split=function(t,n,r){return[e.filter(t,n,r),e.filter(t,(e=>!n(e)),r)]},e.buffer=function(e,t=!1,n=[],r){let i=n.slice(),s=e((e=>{i?i.push(e):a.fire(e)}));r&&r.add(s);const o=()=>{i?.forEach((e=>a.fire(e))),i=null},a=new f({onWillAddFirstListener(){s||(s=e((e=>a.fire(e))),r&&r.add(s))},onDidAddFirstListener(){i&&(t?setTimeout(o):o())},onDidRemoveLastListener(){s&&s.dispose(),s=null}});return r&&r.add(a),a.event},e.chain=function(e,t){return(n,r,i)=>{const s=t(new c);return e((function(e){const t=s.evaluate(e);t!==l&&n.call(r,t)}),void 0,i)}};const l=Symbol("HaltChainable");class c{constructor(){this.steps=[]}map(e){return this.steps.push(e),this}forEach(e){return this.steps.push((t=>(e(t),t))),this}filter(e){return this.steps.push((t=>e(t)?t:l)),this}reduce(e,t){let n=t;return this.steps.push((t=>(n=e(n,t),n))),this}latch(e=(e,t)=>e===t){let t,n=!0;return this.steps.push((r=>{const i=n||!e(r,t);return n=!1,t=r,i?r:l})),this}evaluate(e){for(const t of this.steps)if((e=t(e))===l)break;return e}}e.fromNodeEventEmitter=function(e,t,n=e=>e){const r=(...e)=>i.fire(n(...e)),i=new f({onWillAddFirstListener:()=>e.on(t,r),onDidRemoveLastListener:()=>e.removeListener(t,r)});return i.event},e.fromDOMEventEmitter=function(e,t,n=e=>e){const r=(...e)=>i.fire(n(...e)),i=new f({onWillAddFirstListener:()=>e.addEventListener(t,r),onDidRemoveLastListener:()=>e.removeEventListener(t,r)});return i.event},e.toPromise=function(e){return new Promise((t=>n(e)(t)))},e.fromPromise=function(e){const t=new f;return e.then((e=>{t.fire(e)}),(()=>{t.fire(void 0)})).finally((()=>{t.dispose()})),t.event},e.forward=function(e,t){return e((e=>t.fire(e)))},e.runAndSubscribe=function(e,t,n){return t(n),e((e=>t(e)))};class h{constructor(e,n){this._observable=e,this._counter=0,this._hasChanged=!1;const r={onWillAddFirstListener:()=>{e.addObserver(this),this._observable.reportChanges()},onDidRemoveLastListener:()=>{e.removeObserver(this)}};n||t(),this.emitter=new f(r),n&&n.add(this.emitter)}beginUpdate(e){this._counter++}handlePossibleChange(e){}handleChange(e,t){this._hasChanged=!0}endUpdate(e){this._counter--,0===this._counter&&(this._observable.reportChanges(),this._hasChanged&&(this._hasChanged=!1,this.emitter.fire(this._observable.get())))}}e.fromObservable=function(e,t){return new h(e,t).emitter.event},e.fromObservableLight=function(e){return(t,n,r)=>{let s=0,o=!1;const a={beginUpdate(){s++},endUpdate(){s--,0===s&&(e.reportChanges(),o&&(o=!1,t.call(n)))},handlePossibleChange(){},handleChange(){o=!0}};e.addObserver(a),e.reportChanges();const l={dispose(){e.removeObserver(a)}};return r instanceof i.Cm?r.add(l):Array.isArray(r)&&r.push(l),l}}}(o||(o={}));class a{static{this.all=new Set}static{this._idPool=0}constructor(e){this.listenerCount=0,this.invocationCount=0,this.elapsedOverall=0,this.durations=[],this.name=`${e}_${a._idPool++}`,a.all.add(this)}start(e){this._stopWatch=new s.W,this.listenerCount=e}stop(){if(this._stopWatch){const e=this._stopWatch.elapsed();this.durations.push(e),this.elapsedOverall+=e,this.invocationCount+=1,this._stopWatch=void 0}}}class l{static{this._idPool=1}constructor(e,t,n=(l._idPool++).toString(16).padStart(3,"0")){this._errorHandler=e,this.threshold=t,this.name=n,this._warnCountdown=0}dispose(){this._stacks?.clear()}check(e,t){const n=this.threshold;if(n<=0||t{const t=this._stacks.get(e.value)||0;this._stacks.set(e.value,t-1)}}getMostFrequentStack(){if(!this._stacks)return;let e,t=0;for(const[n,r]of this._stacks)(!e||t{if(this._leakageMon&&this._size>this._leakageMon.threshold**2){const e=`[${this._leakageMon.name}] REFUSES to accept new listeners because it exceeded its threshold by far (${this._size} vs ${this._leakageMon.threshold})`;console.warn(e);const t=this._leakageMon.getMostFrequentStack()??["UNKNOWN stack",-1],n=new u(`${e}. HINT: Stack shows most frequent listener (${t[1]}-times)`,t[0]);return(this._options?.onListenerError||r.dz)(n),i.jG.None}if(this._disposed)return i.jG.None;t&&(e=e.bind(t));const s=new d(e);let o;this._leakageMon&&this._size>=Math.ceil(.2*this._leakageMon.threshold)&&(s.stack=c.create(),o=this._leakageMon.check(s.stack,this._size+1)),this._listeners?this._listeners instanceof d?(this._deliveryQueue??=new m,this._listeners=[this._listeners,s]):this._listeners.push(s):(this._options?.onWillAddFirstListener?.(this),this._listeners=s,this._options?.onDidAddFirstListener?.(this)),this._size++;const a=(0,i.s)((()=>{g?.unregister(a),o?.(),this._removeListener(s)}));if(n instanceof i.Cm?n.add(a):Array.isArray(n)&&n.push(a),g){const e=(new Error).stack.split("\n").slice(2,3).join("\n").trim(),t=/(file:|vscode-file:\/\/vscode-app)?(\/[^:]*:\d+:\d+)/.exec(e);g.register(a,t?.[2]??e,a)}return a},this._event}_removeListener(e){if(this._options?.onWillRemoveListener?.(this),!this._listeners)return;if(1===this._size)return this._listeners=void 0,this._options?.onDidRemoveLastListener?.(this),void(this._size=0);const t=this._listeners,n=t.indexOf(e);if(-1===n)throw console.log("disposed?",this._disposed),console.log("size?",this._size),console.log("arr?",JSON.stringify(this._listeners)),new Error("Attempted to dispose unknown listener");this._size--,t[n]=void 0;const r=this._deliveryQueue.current===this;if(2*this._size<=t.length){let e=0;for(let n=0;n0}}class m{constructor(){this.i=-1,this.end=0}enqueue(e,t,n){this.i=0,this.end=n,this.current=e,this.value=t}reset(){this.i=this.end,this.current=void 0,this.value=void 0}}},1484:(e,t,n)=>{"use strict";function r(e,t){const n=this;let r,i=!1;return function(){if(i)return r;if(i=!0,t)try{r=e.apply(n,arguments)}finally{t()}else r=e.apply(n,arguments);return r}}n.d(t,{jG:()=>g,$w:()=>m,Cm:()=>d,HE:()=>f,qE:()=>h,AS:()=>c,VD:()=>a,s:()=>u,Ay:()=>o});var i=n(2522);let s=null;function o(e){return s?.trackDisposable(e),e}function a(e){s?.markAsDisposed(e)}function l(e,t){s?.setParent(e,t)}function c(e){if(i.f.is(e)){const n=[];for(const r of e)if(r)try{r.dispose()}catch(t){n.push(t)}if(1===n.length)throw n[0];if(n.length>1)throw new AggregateError(n,"Encountered errors while disposing of store");return Array.isArray(e)?[]:e}if(e)return e.dispose(),e}function h(...e){const t=u((()=>c(e)));return function(e,t){if(s)for(const n of e)s.setParent(n,t)}(e,t),t}function u(e){const t=o({dispose:r((()=>{a(t),e()}))});return t}class d{static{this.DISABLE_DISPOSED_WARNING=!1}constructor(){this._toDispose=new Set,this._isDisposed=!1,o(this)}dispose(){this._isDisposed||(a(this),this._isDisposed=!0,this.clear())}get isDisposed(){return this._isDisposed}clear(){if(0!==this._toDispose.size)try{c(this._toDispose)}finally{this._toDispose.clear()}}add(e){if(!e)return e;if(e===this)throw new Error("Cannot register a disposable on itself!");return l(e,this),this._isDisposed?d.DISABLE_DISPOSED_WARNING||console.warn(new Error("Trying to add a disposable to a DisposableStore that has already been disposed of. The added object will be leaked!").stack):this._toDispose.add(e),e}deleteAndLeak(e){e&&this._toDispose.has(e)&&(this._toDispose.delete(e),l(e,null))}}class g{static{this.None=Object.freeze({dispose(){}})}constructor(){this._store=new d,o(this),l(this._store,this)}dispose(){a(this),this._store.dispose()}_register(e){if(e===this)throw new Error("Cannot register a disposable on itself!");return this._store.add(e)}}class f{constructor(){this._isDisposed=!1,o(this)}get value(){return this._isDisposed?void 0:this._value}set value(e){this._isDisposed||e===this._value||(this._value?.dispose(),e&&l(e,this),this._value=e)}clear(){this.value=void 0}dispose(){this._isDisposed=!0,a(this),this._value?.dispose(),this._value=void 0}}class m{constructor(){this._store=new Map,this._isDisposed=!1,o(this)}dispose(){a(this),this._isDisposed=!0,this.clearAndDisposeAll()}clearAndDisposeAll(){if(this._store.size)try{c(this._store.values())}finally{this._store.clear()}}get(e){return this._store.get(e)}set(e,t,n=!1){this._isDisposed&&console.warn(new Error("Trying to add a disposable to a DisposableMap that has already been disposed of. The added object will be leaked!").stack),n||this._store.get(e)?.dispose(),this._store.set(e,t)}deleteAndDispose(e){this._store.get(e)?.dispose(),this._store.delete(e)}[Symbol.iterator](){return this._store[Symbol.iterator]()}}},1508:(e,t,n)=>{"use strict";n.d(t,{$X:()=>O,AV:()=>s,E_:()=>N,HG:()=>d,LJ:()=>y,LU:()=>B,NB:()=>l,OS:()=>c,Q_:()=>k,Ss:()=>R,UD:()=>f,Wv:()=>_,Z5:()=>w,_J:()=>I,aC:()=>A,bm:()=>a,eY:()=>h,jy:()=>o,km:()=>x,lT:()=>g,ne:()=>M,ns:()=>v,pc:()=>C,r_:()=>D,tk:()=>F,tl:()=>z,uz:()=>u,y_:()=>j,z_:()=>L});var r=n(1788),i=n(1090);function s(e){return!e||"string"!==typeof e||0===e.trim().length}function o(e){return e.replace(/[<>"'&]/g,(e=>{switch(e){case"<":return"<";case">":return">";case'"':return""";case"'":return"'";case"&":return"&"}return e}))}function a(e){return e.replace(/[\\\{\}\*\+\?\|\^\$\.\[\]\(\)]/g,"\\$&")}function l(e,t){if(!e||!t)return e;const n=t.length;if(0===n||0===e.length)return e;let r=0;for(;e.indexOf(t,r)===r;)r+=n;return e.substring(r)}function c(e,t,n={}){if(!e)throw new Error("Cannot create regex from empty string");t||(e=a(e)),n.wholeWord&&(/\B/.test(e.charAt(0))||(e="\\b"+e),/\B/.test(e.charAt(e.length-1))||(e+="\\b"));let r="";return n.global&&(r+="g"),n.matchCase||(r+="i"),n.multiline&&(r+="m"),n.unicode&&(r+="u"),new RegExp(e,r)}function h(e){if("^"===e.source||"^$"===e.source||"$"===e.source||"^\\s*$"===e.source)return!1;return!(!e.exec("")||0!==e.lastIndex)}function u(e){return e.split(/\r\n|\r|\n/)}function d(e){for(let t=0,n=e.length;t=0;n--){const t=e.charCodeAt(n);if(32!==t&&9!==t)return n}return-1}function f(e,t){return et?1:0}function m(e,t,n=0,r=e.length,i=0,s=t.length){for(;ns)return 1}const o=r-n,a=s-i;return oa?1:0}function p(e,t,n=0,r=e.length,i=0,s=t.length){for(;n=128||a>=128)return m(e.toLowerCase(),t.toLowerCase(),n,r,i,s);b(o)&&(o-=32),b(a)&&(a-=32);const l=o-a;if(0!==l)return l}const o=r-n,a=s-i;return oa?1:0}function b(e){return e>=97&&e<=122}function _(e){return e>=65&&e<=90}function k(e,t){return e.length===t.length&&0===p(e,t)}function v(e,t){const n=t.length;return!(t.length>e.length)&&0===p(e,t,0,n)}function C(e){return 55296<=e&&e<=56319}function y(e){return 56320<=e&&e<=57343}function L(e,t){return t-56320+(e-55296<<10)+65536}function w(e,t,n){const r=e.charCodeAt(n);if(C(r)&&n+11){const r=e.charCodeAt(t-2);if(C(r))return L(r,n)}return n}(this._str,this._offset);return this._offset-=e>=65536?2:1,e}nextCodePoint(){const e=w(this._str,this._len,this._offset);return this._offset+=e>=65536?2:1,e}eol(){return this._offset>=this._len}}class x{get offset(){return this._iterator.offset}constructor(e,t=0){this._iterator=new S(e,t)}nextGraphemeLength(){const e=V.getInstance(),t=this._iterator,n=t.offset;let r=e.getGraphemeBreakType(t.nextCodePoint());for(;!t.eol();){const n=t.offset,i=e.getGraphemeBreakType(t.nextCodePoint());if(P(r,i)){t.setOffset(n);break}r=i}return t.offset-n}prevGraphemeLength(){const e=V.getInstance(),t=this._iterator,n=t.offset;let r=e.getGraphemeBreakType(t.prevCodePoint());for(;t.offset>0;){const n=t.offset,i=e.getGraphemeBreakType(t.prevCodePoint());if(P(i,r)){t.setOffset(n);break}r=i}return n-t.offset}eol(){return this._iterator.eol()}}let E;function N(e){return E||(E=/(?:[\u05BE\u05C0\u05C3\u05C6\u05D0-\u05F4\u0608\u060B\u060D\u061B-\u064A\u066D-\u066F\u0671-\u06D5\u06E5\u06E6\u06EE\u06EF\u06FA-\u0710\u0712-\u072F\u074D-\u07A5\u07B1-\u07EA\u07F4\u07F5\u07FA\u07FE-\u0815\u081A\u0824\u0828\u0830-\u0858\u085E-\u088E\u08A0-\u08C9\u200F\uFB1D\uFB1F-\uFB28\uFB2A-\uFD3D\uFD50-\uFDC7\uFDF0-\uFDFC\uFE70-\uFEFC]|\uD802[\uDC00-\uDD1B\uDD20-\uDE00\uDE10-\uDE35\uDE40-\uDEE4\uDEEB-\uDF35\uDF40-\uDFFF]|\uD803[\uDC00-\uDD23\uDE80-\uDEA9\uDEAD-\uDF45\uDF51-\uDF81\uDF86-\uDFF6]|\uD83A[\uDC00-\uDCCF\uDD00-\uDD43\uDD4B-\uDFFF]|\uD83B[\uDC00-\uDEBB])/),E.test(e)}const T=/^[\t\n\r\x20-\x7E]*$/;function A(e){return T.test(e)}const I=/[\u2028\u2029]/;function O(e){return I.test(e)}function M(e){return e>=11904&&e<=55215||e>=63744&&e<=64255||e>=65281&&e<=65374}function R(e){return e>=127462&&e<=127487||8986===e||8987===e||9200===e||9203===e||e>=9728&&e<=10175||11088===e||11093===e||e>=127744&&e<=128591||e>=128640&&e<=128764||e>=128992&&e<=129008||e>=129280&&e<=129535||e>=129648&&e<=129782}const D=String.fromCharCode(65279);function B(e){return!!(e&&e.length>0&&65279===e.charCodeAt(0))}function F(e){return(e%=52)<26?String.fromCharCode(97+e):String.fromCharCode(65+e-26)}function P(e,t){return 0===e?5!==t&&7!==t:(2!==e||3!==t)&&(4===e||2===e||3===e||(4===t||2===t||3===t||(8!==e||8!==t&&9!==t&&11!==t&&12!==t)&&((11!==e&&9!==e||9!==t&&10!==t)&&((12!==e&&10!==e||10!==t)&&(5!==t&&13!==t&&(7!==t&&(1!==e&&((13!==e||14!==t)&&(6!==e||6!==t)))))))))}class V{static{this._INSTANCE=null}static getInstance(){return V._INSTANCE||(V._INSTANCE=new V),V._INSTANCE}constructor(){this._data=JSON.parse("[0,0,0,51229,51255,12,44061,44087,12,127462,127487,6,7083,7085,5,47645,47671,12,54813,54839,12,128678,128678,14,3270,3270,5,9919,9923,14,45853,45879,12,49437,49463,12,53021,53047,12,71216,71218,7,128398,128399,14,129360,129374,14,2519,2519,5,4448,4519,9,9742,9742,14,12336,12336,14,44957,44983,12,46749,46775,12,48541,48567,12,50333,50359,12,52125,52151,12,53917,53943,12,69888,69890,5,73018,73018,5,127990,127990,14,128558,128559,14,128759,128760,14,129653,129655,14,2027,2035,5,2891,2892,7,3761,3761,5,6683,6683,5,8293,8293,4,9825,9826,14,9999,9999,14,43452,43453,5,44509,44535,12,45405,45431,12,46301,46327,12,47197,47223,12,48093,48119,12,48989,49015,12,49885,49911,12,50781,50807,12,51677,51703,12,52573,52599,12,53469,53495,12,54365,54391,12,65279,65279,4,70471,70472,7,72145,72147,7,119173,119179,5,127799,127818,14,128240,128244,14,128512,128512,14,128652,128652,14,128721,128722,14,129292,129292,14,129445,129450,14,129734,129743,14,1476,1477,5,2366,2368,7,2750,2752,7,3076,3076,5,3415,3415,5,4141,4144,5,6109,6109,5,6964,6964,5,7394,7400,5,9197,9198,14,9770,9770,14,9877,9877,14,9968,9969,14,10084,10084,14,43052,43052,5,43713,43713,5,44285,44311,12,44733,44759,12,45181,45207,12,45629,45655,12,46077,46103,12,46525,46551,12,46973,46999,12,47421,47447,12,47869,47895,12,48317,48343,12,48765,48791,12,49213,49239,12,49661,49687,12,50109,50135,12,50557,50583,12,51005,51031,12,51453,51479,12,51901,51927,12,52349,52375,12,52797,52823,12,53245,53271,12,53693,53719,12,54141,54167,12,54589,54615,12,55037,55063,12,69506,69509,5,70191,70193,5,70841,70841,7,71463,71467,5,72330,72342,5,94031,94031,5,123628,123631,5,127763,127765,14,127941,127941,14,128043,128062,14,128302,128317,14,128465,128467,14,128539,128539,14,128640,128640,14,128662,128662,14,128703,128703,14,128745,128745,14,129004,129007,14,129329,129330,14,129402,129402,14,129483,129483,14,129686,129704,14,130048,131069,14,173,173,4,1757,1757,1,2200,2207,5,2434,2435,7,2631,2632,5,2817,2817,5,3008,3008,5,3201,3201,5,3387,3388,5,3542,3542,5,3902,3903,7,4190,4192,5,6002,6003,5,6439,6440,5,6765,6770,7,7019,7027,5,7154,7155,7,8205,8205,13,8505,8505,14,9654,9654,14,9757,9757,14,9792,9792,14,9852,9853,14,9890,9894,14,9937,9937,14,9981,9981,14,10035,10036,14,11035,11036,14,42654,42655,5,43346,43347,7,43587,43587,5,44006,44007,7,44173,44199,12,44397,44423,12,44621,44647,12,44845,44871,12,45069,45095,12,45293,45319,12,45517,45543,12,45741,45767,12,45965,45991,12,46189,46215,12,46413,46439,12,46637,46663,12,46861,46887,12,47085,47111,12,47309,47335,12,47533,47559,12,47757,47783,12,47981,48007,12,48205,48231,12,48429,48455,12,48653,48679,12,48877,48903,12,49101,49127,12,49325,49351,12,49549,49575,12,49773,49799,12,49997,50023,12,50221,50247,12,50445,50471,12,50669,50695,12,50893,50919,12,51117,51143,12,51341,51367,12,51565,51591,12,51789,51815,12,52013,52039,12,52237,52263,12,52461,52487,12,52685,52711,12,52909,52935,12,53133,53159,12,53357,53383,12,53581,53607,12,53805,53831,12,54029,54055,12,54253,54279,12,54477,54503,12,54701,54727,12,54925,54951,12,55149,55175,12,68101,68102,5,69762,69762,7,70067,70069,7,70371,70378,5,70720,70721,7,71087,71087,5,71341,71341,5,71995,71996,5,72249,72249,7,72850,72871,5,73109,73109,5,118576,118598,5,121505,121519,5,127245,127247,14,127568,127569,14,127777,127777,14,127872,127891,14,127956,127967,14,128015,128016,14,128110,128172,14,128259,128259,14,128367,128368,14,128424,128424,14,128488,128488,14,128530,128532,14,128550,128551,14,128566,128566,14,128647,128647,14,128656,128656,14,128667,128673,14,128691,128693,14,128715,128715,14,128728,128732,14,128752,128752,14,128765,128767,14,129096,129103,14,129311,129311,14,129344,129349,14,129394,129394,14,129413,129425,14,129466,129471,14,129511,129535,14,129664,129666,14,129719,129722,14,129760,129767,14,917536,917631,5,13,13,2,1160,1161,5,1564,1564,4,1807,1807,1,2085,2087,5,2307,2307,7,2382,2383,7,2497,2500,5,2563,2563,7,2677,2677,5,2763,2764,7,2879,2879,5,2914,2915,5,3021,3021,5,3142,3144,5,3263,3263,5,3285,3286,5,3398,3400,7,3530,3530,5,3633,3633,5,3864,3865,5,3974,3975,5,4155,4156,7,4229,4230,5,5909,5909,7,6078,6085,7,6277,6278,5,6451,6456,7,6744,6750,5,6846,6846,5,6972,6972,5,7074,7077,5,7146,7148,7,7222,7223,5,7416,7417,5,8234,8238,4,8417,8417,5,9000,9000,14,9203,9203,14,9730,9731,14,9748,9749,14,9762,9763,14,9776,9783,14,9800,9811,14,9831,9831,14,9872,9873,14,9882,9882,14,9900,9903,14,9929,9933,14,9941,9960,14,9974,9974,14,9989,9989,14,10006,10006,14,10062,10062,14,10160,10160,14,11647,11647,5,12953,12953,14,43019,43019,5,43232,43249,5,43443,43443,5,43567,43568,7,43696,43696,5,43765,43765,7,44013,44013,5,44117,44143,12,44229,44255,12,44341,44367,12,44453,44479,12,44565,44591,12,44677,44703,12,44789,44815,12,44901,44927,12,45013,45039,12,45125,45151,12,45237,45263,12,45349,45375,12,45461,45487,12,45573,45599,12,45685,45711,12,45797,45823,12,45909,45935,12,46021,46047,12,46133,46159,12,46245,46271,12,46357,46383,12,46469,46495,12,46581,46607,12,46693,46719,12,46805,46831,12,46917,46943,12,47029,47055,12,47141,47167,12,47253,47279,12,47365,47391,12,47477,47503,12,47589,47615,12,47701,47727,12,47813,47839,12,47925,47951,12,48037,48063,12,48149,48175,12,48261,48287,12,48373,48399,12,48485,48511,12,48597,48623,12,48709,48735,12,48821,48847,12,48933,48959,12,49045,49071,12,49157,49183,12,49269,49295,12,49381,49407,12,49493,49519,12,49605,49631,12,49717,49743,12,49829,49855,12,49941,49967,12,50053,50079,12,50165,50191,12,50277,50303,12,50389,50415,12,50501,50527,12,50613,50639,12,50725,50751,12,50837,50863,12,50949,50975,12,51061,51087,12,51173,51199,12,51285,51311,12,51397,51423,12,51509,51535,12,51621,51647,12,51733,51759,12,51845,51871,12,51957,51983,12,52069,52095,12,52181,52207,12,52293,52319,12,52405,52431,12,52517,52543,12,52629,52655,12,52741,52767,12,52853,52879,12,52965,52991,12,53077,53103,12,53189,53215,12,53301,53327,12,53413,53439,12,53525,53551,12,53637,53663,12,53749,53775,12,53861,53887,12,53973,53999,12,54085,54111,12,54197,54223,12,54309,54335,12,54421,54447,12,54533,54559,12,54645,54671,12,54757,54783,12,54869,54895,12,54981,55007,12,55093,55119,12,55243,55291,10,66045,66045,5,68325,68326,5,69688,69702,5,69817,69818,5,69957,69958,7,70089,70092,5,70198,70199,5,70462,70462,5,70502,70508,5,70750,70750,5,70846,70846,7,71100,71101,5,71230,71230,7,71351,71351,5,71737,71738,5,72000,72000,7,72160,72160,5,72273,72278,5,72752,72758,5,72882,72883,5,73031,73031,5,73461,73462,7,94192,94193,7,119149,119149,7,121403,121452,5,122915,122916,5,126980,126980,14,127358,127359,14,127535,127535,14,127759,127759,14,127771,127771,14,127792,127793,14,127825,127867,14,127897,127899,14,127945,127945,14,127985,127986,14,128000,128007,14,128021,128021,14,128066,128100,14,128184,128235,14,128249,128252,14,128266,128276,14,128335,128335,14,128379,128390,14,128407,128419,14,128444,128444,14,128481,128481,14,128499,128499,14,128526,128526,14,128536,128536,14,128543,128543,14,128556,128556,14,128564,128564,14,128577,128580,14,128643,128645,14,128649,128649,14,128654,128654,14,128660,128660,14,128664,128664,14,128675,128675,14,128686,128689,14,128695,128696,14,128705,128709,14,128717,128719,14,128725,128725,14,128736,128741,14,128747,128748,14,128755,128755,14,128762,128762,14,128981,128991,14,129009,129023,14,129160,129167,14,129296,129304,14,129320,129327,14,129340,129342,14,129356,129356,14,129388,129392,14,129399,129400,14,129404,129407,14,129432,129442,14,129454,129455,14,129473,129474,14,129485,129487,14,129648,129651,14,129659,129660,14,129671,129679,14,129709,129711,14,129728,129730,14,129751,129753,14,129776,129782,14,917505,917505,4,917760,917999,5,10,10,3,127,159,4,768,879,5,1471,1471,5,1536,1541,1,1648,1648,5,1767,1768,5,1840,1866,5,2070,2073,5,2137,2139,5,2274,2274,1,2363,2363,7,2377,2380,7,2402,2403,5,2494,2494,5,2507,2508,7,2558,2558,5,2622,2624,7,2641,2641,5,2691,2691,7,2759,2760,5,2786,2787,5,2876,2876,5,2881,2884,5,2901,2902,5,3006,3006,5,3014,3016,7,3072,3072,5,3134,3136,5,3157,3158,5,3260,3260,5,3266,3266,5,3274,3275,7,3328,3329,5,3391,3392,7,3405,3405,5,3457,3457,5,3536,3537,7,3551,3551,5,3636,3642,5,3764,3772,5,3895,3895,5,3967,3967,7,3993,4028,5,4146,4151,5,4182,4183,7,4226,4226,5,4253,4253,5,4957,4959,5,5940,5940,7,6070,6070,7,6087,6088,7,6158,6158,4,6432,6434,5,6448,6449,7,6679,6680,5,6742,6742,5,6754,6754,5,6783,6783,5,6912,6915,5,6966,6970,5,6978,6978,5,7042,7042,7,7080,7081,5,7143,7143,7,7150,7150,7,7212,7219,5,7380,7392,5,7412,7412,5,8203,8203,4,8232,8232,4,8265,8265,14,8400,8412,5,8421,8432,5,8617,8618,14,9167,9167,14,9200,9200,14,9410,9410,14,9723,9726,14,9733,9733,14,9745,9745,14,9752,9752,14,9760,9760,14,9766,9766,14,9774,9774,14,9786,9786,14,9794,9794,14,9823,9823,14,9828,9828,14,9833,9850,14,9855,9855,14,9875,9875,14,9880,9880,14,9885,9887,14,9896,9897,14,9906,9916,14,9926,9927,14,9935,9935,14,9939,9939,14,9962,9962,14,9972,9972,14,9978,9978,14,9986,9986,14,9997,9997,14,10002,10002,14,10017,10017,14,10055,10055,14,10071,10071,14,10133,10135,14,10548,10549,14,11093,11093,14,12330,12333,5,12441,12442,5,42608,42610,5,43010,43010,5,43045,43046,5,43188,43203,7,43302,43309,5,43392,43394,5,43446,43449,5,43493,43493,5,43571,43572,7,43597,43597,7,43703,43704,5,43756,43757,5,44003,44004,7,44009,44010,7,44033,44059,12,44089,44115,12,44145,44171,12,44201,44227,12,44257,44283,12,44313,44339,12,44369,44395,12,44425,44451,12,44481,44507,12,44537,44563,12,44593,44619,12,44649,44675,12,44705,44731,12,44761,44787,12,44817,44843,12,44873,44899,12,44929,44955,12,44985,45011,12,45041,45067,12,45097,45123,12,45153,45179,12,45209,45235,12,45265,45291,12,45321,45347,12,45377,45403,12,45433,45459,12,45489,45515,12,45545,45571,12,45601,45627,12,45657,45683,12,45713,45739,12,45769,45795,12,45825,45851,12,45881,45907,12,45937,45963,12,45993,46019,12,46049,46075,12,46105,46131,12,46161,46187,12,46217,46243,12,46273,46299,12,46329,46355,12,46385,46411,12,46441,46467,12,46497,46523,12,46553,46579,12,46609,46635,12,46665,46691,12,46721,46747,12,46777,46803,12,46833,46859,12,46889,46915,12,46945,46971,12,47001,47027,12,47057,47083,12,47113,47139,12,47169,47195,12,47225,47251,12,47281,47307,12,47337,47363,12,47393,47419,12,47449,47475,12,47505,47531,12,47561,47587,12,47617,47643,12,47673,47699,12,47729,47755,12,47785,47811,12,47841,47867,12,47897,47923,12,47953,47979,12,48009,48035,12,48065,48091,12,48121,48147,12,48177,48203,12,48233,48259,12,48289,48315,12,48345,48371,12,48401,48427,12,48457,48483,12,48513,48539,12,48569,48595,12,48625,48651,12,48681,48707,12,48737,48763,12,48793,48819,12,48849,48875,12,48905,48931,12,48961,48987,12,49017,49043,12,49073,49099,12,49129,49155,12,49185,49211,12,49241,49267,12,49297,49323,12,49353,49379,12,49409,49435,12,49465,49491,12,49521,49547,12,49577,49603,12,49633,49659,12,49689,49715,12,49745,49771,12,49801,49827,12,49857,49883,12,49913,49939,12,49969,49995,12,50025,50051,12,50081,50107,12,50137,50163,12,50193,50219,12,50249,50275,12,50305,50331,12,50361,50387,12,50417,50443,12,50473,50499,12,50529,50555,12,50585,50611,12,50641,50667,12,50697,50723,12,50753,50779,12,50809,50835,12,50865,50891,12,50921,50947,12,50977,51003,12,51033,51059,12,51089,51115,12,51145,51171,12,51201,51227,12,51257,51283,12,51313,51339,12,51369,51395,12,51425,51451,12,51481,51507,12,51537,51563,12,51593,51619,12,51649,51675,12,51705,51731,12,51761,51787,12,51817,51843,12,51873,51899,12,51929,51955,12,51985,52011,12,52041,52067,12,52097,52123,12,52153,52179,12,52209,52235,12,52265,52291,12,52321,52347,12,52377,52403,12,52433,52459,12,52489,52515,12,52545,52571,12,52601,52627,12,52657,52683,12,52713,52739,12,52769,52795,12,52825,52851,12,52881,52907,12,52937,52963,12,52993,53019,12,53049,53075,12,53105,53131,12,53161,53187,12,53217,53243,12,53273,53299,12,53329,53355,12,53385,53411,12,53441,53467,12,53497,53523,12,53553,53579,12,53609,53635,12,53665,53691,12,53721,53747,12,53777,53803,12,53833,53859,12,53889,53915,12,53945,53971,12,54001,54027,12,54057,54083,12,54113,54139,12,54169,54195,12,54225,54251,12,54281,54307,12,54337,54363,12,54393,54419,12,54449,54475,12,54505,54531,12,54561,54587,12,54617,54643,12,54673,54699,12,54729,54755,12,54785,54811,12,54841,54867,12,54897,54923,12,54953,54979,12,55009,55035,12,55065,55091,12,55121,55147,12,55177,55203,12,65024,65039,5,65520,65528,4,66422,66426,5,68152,68154,5,69291,69292,5,69633,69633,5,69747,69748,5,69811,69814,5,69826,69826,5,69932,69932,7,70016,70017,5,70079,70080,7,70095,70095,5,70196,70196,5,70367,70367,5,70402,70403,7,70464,70464,5,70487,70487,5,70709,70711,7,70725,70725,7,70833,70834,7,70843,70844,7,70849,70849,7,71090,71093,5,71103,71104,5,71227,71228,7,71339,71339,5,71344,71349,5,71458,71461,5,71727,71735,5,71985,71989,7,71998,71998,5,72002,72002,7,72154,72155,5,72193,72202,5,72251,72254,5,72281,72283,5,72344,72345,5,72766,72766,7,72874,72880,5,72885,72886,5,73023,73029,5,73104,73105,5,73111,73111,5,92912,92916,5,94095,94098,5,113824,113827,4,119142,119142,7,119155,119162,4,119362,119364,5,121476,121476,5,122888,122904,5,123184,123190,5,125252,125258,5,127183,127183,14,127340,127343,14,127377,127386,14,127491,127503,14,127548,127551,14,127744,127756,14,127761,127761,14,127769,127769,14,127773,127774,14,127780,127788,14,127796,127797,14,127820,127823,14,127869,127869,14,127894,127895,14,127902,127903,14,127943,127943,14,127947,127950,14,127972,127972,14,127988,127988,14,127992,127994,14,128009,128011,14,128019,128019,14,128023,128041,14,128064,128064,14,128102,128107,14,128174,128181,14,128238,128238,14,128246,128247,14,128254,128254,14,128264,128264,14,128278,128299,14,128329,128330,14,128348,128359,14,128371,128377,14,128392,128393,14,128401,128404,14,128421,128421,14,128433,128434,14,128450,128452,14,128476,128478,14,128483,128483,14,128495,128495,14,128506,128506,14,128519,128520,14,128528,128528,14,128534,128534,14,128538,128538,14,128540,128542,14,128544,128549,14,128552,128555,14,128557,128557,14,128560,128563,14,128565,128565,14,128567,128576,14,128581,128591,14,128641,128642,14,128646,128646,14,128648,128648,14,128650,128651,14,128653,128653,14,128655,128655,14,128657,128659,14,128661,128661,14,128663,128663,14,128665,128666,14,128674,128674,14,128676,128677,14,128679,128685,14,128690,128690,14,128694,128694,14,128697,128702,14,128704,128704,14,128710,128714,14,128716,128716,14,128720,128720,14,128723,128724,14,128726,128727,14,128733,128735,14,128742,128744,14,128746,128746,14,128749,128751,14,128753,128754,14,128756,128758,14,128761,128761,14,128763,128764,14,128884,128895,14,128992,129003,14,129008,129008,14,129036,129039,14,129114,129119,14,129198,129279,14,129293,129295,14,129305,129310,14,129312,129319,14,129328,129328,14,129331,129338,14,129343,129343,14,129351,129355,14,129357,129359,14,129375,129387,14,129393,129393,14,129395,129398,14,129401,129401,14,129403,129403,14,129408,129412,14,129426,129431,14,129443,129444,14,129451,129453,14,129456,129465,14,129472,129472,14,129475,129482,14,129484,129484,14,129488,129510,14,129536,129647,14,129652,129652,14,129656,129658,14,129661,129663,14,129667,129670,14,129680,129685,14,129705,129708,14,129712,129718,14,129723,129727,14,129731,129733,14,129744,129750,14,129754,129759,14,129768,129775,14,129783,129791,14,917504,917504,4,917506,917535,4,917632,917759,4,918000,921599,4,0,9,4,11,12,4,14,31,4,169,169,14,174,174,14,1155,1159,5,1425,1469,5,1473,1474,5,1479,1479,5,1552,1562,5,1611,1631,5,1750,1756,5,1759,1764,5,1770,1773,5,1809,1809,5,1958,1968,5,2045,2045,5,2075,2083,5,2089,2093,5,2192,2193,1,2250,2273,5,2275,2306,5,2362,2362,5,2364,2364,5,2369,2376,5,2381,2381,5,2385,2391,5,2433,2433,5,2492,2492,5,2495,2496,7,2503,2504,7,2509,2509,5,2530,2531,5,2561,2562,5,2620,2620,5,2625,2626,5,2635,2637,5,2672,2673,5,2689,2690,5,2748,2748,5,2753,2757,5,2761,2761,7,2765,2765,5,2810,2815,5,2818,2819,7,2878,2878,5,2880,2880,7,2887,2888,7,2893,2893,5,2903,2903,5,2946,2946,5,3007,3007,7,3009,3010,7,3018,3020,7,3031,3031,5,3073,3075,7,3132,3132,5,3137,3140,7,3146,3149,5,3170,3171,5,3202,3203,7,3262,3262,7,3264,3265,7,3267,3268,7,3271,3272,7,3276,3277,5,3298,3299,5,3330,3331,7,3390,3390,5,3393,3396,5,3402,3404,7,3406,3406,1,3426,3427,5,3458,3459,7,3535,3535,5,3538,3540,5,3544,3550,7,3570,3571,7,3635,3635,7,3655,3662,5,3763,3763,7,3784,3789,5,3893,3893,5,3897,3897,5,3953,3966,5,3968,3972,5,3981,3991,5,4038,4038,5,4145,4145,7,4153,4154,5,4157,4158,5,4184,4185,5,4209,4212,5,4228,4228,7,4237,4237,5,4352,4447,8,4520,4607,10,5906,5908,5,5938,5939,5,5970,5971,5,6068,6069,5,6071,6077,5,6086,6086,5,6089,6099,5,6155,6157,5,6159,6159,5,6313,6313,5,6435,6438,7,6441,6443,7,6450,6450,5,6457,6459,5,6681,6682,7,6741,6741,7,6743,6743,7,6752,6752,5,6757,6764,5,6771,6780,5,6832,6845,5,6847,6862,5,6916,6916,7,6965,6965,5,6971,6971,7,6973,6977,7,6979,6980,7,7040,7041,5,7073,7073,7,7078,7079,7,7082,7082,7,7142,7142,5,7144,7145,5,7149,7149,5,7151,7153,5,7204,7211,7,7220,7221,7,7376,7378,5,7393,7393,7,7405,7405,5,7415,7415,7,7616,7679,5,8204,8204,5,8206,8207,4,8233,8233,4,8252,8252,14,8288,8292,4,8294,8303,4,8413,8416,5,8418,8420,5,8482,8482,14,8596,8601,14,8986,8987,14,9096,9096,14,9193,9196,14,9199,9199,14,9201,9202,14,9208,9210,14,9642,9643,14,9664,9664,14,9728,9729,14,9732,9732,14,9735,9741,14,9743,9744,14,9746,9746,14,9750,9751,14,9753,9756,14,9758,9759,14,9761,9761,14,9764,9765,14,9767,9769,14,9771,9773,14,9775,9775,14,9784,9785,14,9787,9791,14,9793,9793,14,9795,9799,14,9812,9822,14,9824,9824,14,9827,9827,14,9829,9830,14,9832,9832,14,9851,9851,14,9854,9854,14,9856,9861,14,9874,9874,14,9876,9876,14,9878,9879,14,9881,9881,14,9883,9884,14,9888,9889,14,9895,9895,14,9898,9899,14,9904,9905,14,9917,9918,14,9924,9925,14,9928,9928,14,9934,9934,14,9936,9936,14,9938,9938,14,9940,9940,14,9961,9961,14,9963,9967,14,9970,9971,14,9973,9973,14,9975,9977,14,9979,9980,14,9982,9985,14,9987,9988,14,9992,9996,14,9998,9998,14,10000,10001,14,10004,10004,14,10013,10013,14,10024,10024,14,10052,10052,14,10060,10060,14,10067,10069,14,10083,10083,14,10085,10087,14,10145,10145,14,10175,10175,14,11013,11015,14,11088,11088,14,11503,11505,5,11744,11775,5,12334,12335,5,12349,12349,14,12951,12951,14,42607,42607,5,42612,42621,5,42736,42737,5,43014,43014,5,43043,43044,7,43047,43047,7,43136,43137,7,43204,43205,5,43263,43263,5,43335,43345,5,43360,43388,8,43395,43395,7,43444,43445,7,43450,43451,7,43454,43456,7,43561,43566,5,43569,43570,5,43573,43574,5,43596,43596,5,43644,43644,5,43698,43700,5,43710,43711,5,43755,43755,7,43758,43759,7,43766,43766,5,44005,44005,5,44008,44008,5,44012,44012,7,44032,44032,11,44060,44060,11,44088,44088,11,44116,44116,11,44144,44144,11,44172,44172,11,44200,44200,11,44228,44228,11,44256,44256,11,44284,44284,11,44312,44312,11,44340,44340,11,44368,44368,11,44396,44396,11,44424,44424,11,44452,44452,11,44480,44480,11,44508,44508,11,44536,44536,11,44564,44564,11,44592,44592,11,44620,44620,11,44648,44648,11,44676,44676,11,44704,44704,11,44732,44732,11,44760,44760,11,44788,44788,11,44816,44816,11,44844,44844,11,44872,44872,11,44900,44900,11,44928,44928,11,44956,44956,11,44984,44984,11,45012,45012,11,45040,45040,11,45068,45068,11,45096,45096,11,45124,45124,11,45152,45152,11,45180,45180,11,45208,45208,11,45236,45236,11,45264,45264,11,45292,45292,11,45320,45320,11,45348,45348,11,45376,45376,11,45404,45404,11,45432,45432,11,45460,45460,11,45488,45488,11,45516,45516,11,45544,45544,11,45572,45572,11,45600,45600,11,45628,45628,11,45656,45656,11,45684,45684,11,45712,45712,11,45740,45740,11,45768,45768,11,45796,45796,11,45824,45824,11,45852,45852,11,45880,45880,11,45908,45908,11,45936,45936,11,45964,45964,11,45992,45992,11,46020,46020,11,46048,46048,11,46076,46076,11,46104,46104,11,46132,46132,11,46160,46160,11,46188,46188,11,46216,46216,11,46244,46244,11,46272,46272,11,46300,46300,11,46328,46328,11,46356,46356,11,46384,46384,11,46412,46412,11,46440,46440,11,46468,46468,11,46496,46496,11,46524,46524,11,46552,46552,11,46580,46580,11,46608,46608,11,46636,46636,11,46664,46664,11,46692,46692,11,46720,46720,11,46748,46748,11,46776,46776,11,46804,46804,11,46832,46832,11,46860,46860,11,46888,46888,11,46916,46916,11,46944,46944,11,46972,46972,11,47000,47000,11,47028,47028,11,47056,47056,11,47084,47084,11,47112,47112,11,47140,47140,11,47168,47168,11,47196,47196,11,47224,47224,11,47252,47252,11,47280,47280,11,47308,47308,11,47336,47336,11,47364,47364,11,47392,47392,11,47420,47420,11,47448,47448,11,47476,47476,11,47504,47504,11,47532,47532,11,47560,47560,11,47588,47588,11,47616,47616,11,47644,47644,11,47672,47672,11,47700,47700,11,47728,47728,11,47756,47756,11,47784,47784,11,47812,47812,11,47840,47840,11,47868,47868,11,47896,47896,11,47924,47924,11,47952,47952,11,47980,47980,11,48008,48008,11,48036,48036,11,48064,48064,11,48092,48092,11,48120,48120,11,48148,48148,11,48176,48176,11,48204,48204,11,48232,48232,11,48260,48260,11,48288,48288,11,48316,48316,11,48344,48344,11,48372,48372,11,48400,48400,11,48428,48428,11,48456,48456,11,48484,48484,11,48512,48512,11,48540,48540,11,48568,48568,11,48596,48596,11,48624,48624,11,48652,48652,11,48680,48680,11,48708,48708,11,48736,48736,11,48764,48764,11,48792,48792,11,48820,48820,11,48848,48848,11,48876,48876,11,48904,48904,11,48932,48932,11,48960,48960,11,48988,48988,11,49016,49016,11,49044,49044,11,49072,49072,11,49100,49100,11,49128,49128,11,49156,49156,11,49184,49184,11,49212,49212,11,49240,49240,11,49268,49268,11,49296,49296,11,49324,49324,11,49352,49352,11,49380,49380,11,49408,49408,11,49436,49436,11,49464,49464,11,49492,49492,11,49520,49520,11,49548,49548,11,49576,49576,11,49604,49604,11,49632,49632,11,49660,49660,11,49688,49688,11,49716,49716,11,49744,49744,11,49772,49772,11,49800,49800,11,49828,49828,11,49856,49856,11,49884,49884,11,49912,49912,11,49940,49940,11,49968,49968,11,49996,49996,11,50024,50024,11,50052,50052,11,50080,50080,11,50108,50108,11,50136,50136,11,50164,50164,11,50192,50192,11,50220,50220,11,50248,50248,11,50276,50276,11,50304,50304,11,50332,50332,11,50360,50360,11,50388,50388,11,50416,50416,11,50444,50444,11,50472,50472,11,50500,50500,11,50528,50528,11,50556,50556,11,50584,50584,11,50612,50612,11,50640,50640,11,50668,50668,11,50696,50696,11,50724,50724,11,50752,50752,11,50780,50780,11,50808,50808,11,50836,50836,11,50864,50864,11,50892,50892,11,50920,50920,11,50948,50948,11,50976,50976,11,51004,51004,11,51032,51032,11,51060,51060,11,51088,51088,11,51116,51116,11,51144,51144,11,51172,51172,11,51200,51200,11,51228,51228,11,51256,51256,11,51284,51284,11,51312,51312,11,51340,51340,11,51368,51368,11,51396,51396,11,51424,51424,11,51452,51452,11,51480,51480,11,51508,51508,11,51536,51536,11,51564,51564,11,51592,51592,11,51620,51620,11,51648,51648,11,51676,51676,11,51704,51704,11,51732,51732,11,51760,51760,11,51788,51788,11,51816,51816,11,51844,51844,11,51872,51872,11,51900,51900,11,51928,51928,11,51956,51956,11,51984,51984,11,52012,52012,11,52040,52040,11,52068,52068,11,52096,52096,11,52124,52124,11,52152,52152,11,52180,52180,11,52208,52208,11,52236,52236,11,52264,52264,11,52292,52292,11,52320,52320,11,52348,52348,11,52376,52376,11,52404,52404,11,52432,52432,11,52460,52460,11,52488,52488,11,52516,52516,11,52544,52544,11,52572,52572,11,52600,52600,11,52628,52628,11,52656,52656,11,52684,52684,11,52712,52712,11,52740,52740,11,52768,52768,11,52796,52796,11,52824,52824,11,52852,52852,11,52880,52880,11,52908,52908,11,52936,52936,11,52964,52964,11,52992,52992,11,53020,53020,11,53048,53048,11,53076,53076,11,53104,53104,11,53132,53132,11,53160,53160,11,53188,53188,11,53216,53216,11,53244,53244,11,53272,53272,11,53300,53300,11,53328,53328,11,53356,53356,11,53384,53384,11,53412,53412,11,53440,53440,11,53468,53468,11,53496,53496,11,53524,53524,11,53552,53552,11,53580,53580,11,53608,53608,11,53636,53636,11,53664,53664,11,53692,53692,11,53720,53720,11,53748,53748,11,53776,53776,11,53804,53804,11,53832,53832,11,53860,53860,11,53888,53888,11,53916,53916,11,53944,53944,11,53972,53972,11,54000,54000,11,54028,54028,11,54056,54056,11,54084,54084,11,54112,54112,11,54140,54140,11,54168,54168,11,54196,54196,11,54224,54224,11,54252,54252,11,54280,54280,11,54308,54308,11,54336,54336,11,54364,54364,11,54392,54392,11,54420,54420,11,54448,54448,11,54476,54476,11,54504,54504,11,54532,54532,11,54560,54560,11,54588,54588,11,54616,54616,11,54644,54644,11,54672,54672,11,54700,54700,11,54728,54728,11,54756,54756,11,54784,54784,11,54812,54812,11,54840,54840,11,54868,54868,11,54896,54896,11,54924,54924,11,54952,54952,11,54980,54980,11,55008,55008,11,55036,55036,11,55064,55064,11,55092,55092,11,55120,55120,11,55148,55148,11,55176,55176,11,55216,55238,9,64286,64286,5,65056,65071,5,65438,65439,5,65529,65531,4,66272,66272,5,68097,68099,5,68108,68111,5,68159,68159,5,68900,68903,5,69446,69456,5,69632,69632,7,69634,69634,7,69744,69744,5,69759,69761,5,69808,69810,7,69815,69816,7,69821,69821,1,69837,69837,1,69927,69931,5,69933,69940,5,70003,70003,5,70018,70018,7,70070,70078,5,70082,70083,1,70094,70094,7,70188,70190,7,70194,70195,7,70197,70197,7,70206,70206,5,70368,70370,7,70400,70401,5,70459,70460,5,70463,70463,7,70465,70468,7,70475,70477,7,70498,70499,7,70512,70516,5,70712,70719,5,70722,70724,5,70726,70726,5,70832,70832,5,70835,70840,5,70842,70842,5,70845,70845,5,70847,70848,5,70850,70851,5,71088,71089,7,71096,71099,7,71102,71102,7,71132,71133,5,71219,71226,5,71229,71229,5,71231,71232,5,71340,71340,7,71342,71343,7,71350,71350,7,71453,71455,5,71462,71462,7,71724,71726,7,71736,71736,7,71984,71984,5,71991,71992,7,71997,71997,7,71999,71999,1,72001,72001,1,72003,72003,5,72148,72151,5,72156,72159,7,72164,72164,7,72243,72248,5,72250,72250,1,72263,72263,5,72279,72280,7,72324,72329,1,72343,72343,7,72751,72751,7,72760,72765,5,72767,72767,5,72873,72873,7,72881,72881,7,72884,72884,7,73009,73014,5,73020,73021,5,73030,73030,1,73098,73102,7,73107,73108,7,73110,73110,7,73459,73460,5,78896,78904,4,92976,92982,5,94033,94087,7,94180,94180,5,113821,113822,5,118528,118573,5,119141,119141,5,119143,119145,5,119150,119154,5,119163,119170,5,119210,119213,5,121344,121398,5,121461,121461,5,121499,121503,5,122880,122886,5,122907,122913,5,122918,122922,5,123566,123566,5,125136,125142,5,126976,126979,14,126981,127182,14,127184,127231,14,127279,127279,14,127344,127345,14,127374,127374,14,127405,127461,14,127489,127490,14,127514,127514,14,127538,127546,14,127561,127567,14,127570,127743,14,127757,127758,14,127760,127760,14,127762,127762,14,127766,127768,14,127770,127770,14,127772,127772,14,127775,127776,14,127778,127779,14,127789,127791,14,127794,127795,14,127798,127798,14,127819,127819,14,127824,127824,14,127868,127868,14,127870,127871,14,127892,127893,14,127896,127896,14,127900,127901,14,127904,127940,14,127942,127942,14,127944,127944,14,127946,127946,14,127951,127955,14,127968,127971,14,127973,127984,14,127987,127987,14,127989,127989,14,127991,127991,14,127995,127999,5,128008,128008,14,128012,128014,14,128017,128018,14,128020,128020,14,128022,128022,14,128042,128042,14,128063,128063,14,128065,128065,14,128101,128101,14,128108,128109,14,128173,128173,14,128182,128183,14,128236,128237,14,128239,128239,14,128245,128245,14,128248,128248,14,128253,128253,14,128255,128258,14,128260,128263,14,128265,128265,14,128277,128277,14,128300,128301,14,128326,128328,14,128331,128334,14,128336,128347,14,128360,128366,14,128369,128370,14,128378,128378,14,128391,128391,14,128394,128397,14,128400,128400,14,128405,128406,14,128420,128420,14,128422,128423,14,128425,128432,14,128435,128443,14,128445,128449,14,128453,128464,14,128468,128475,14,128479,128480,14,128482,128482,14,128484,128487,14,128489,128494,14,128496,128498,14,128500,128505,14,128507,128511,14,128513,128518,14,128521,128525,14,128527,128527,14,128529,128529,14,128533,128533,14,128535,128535,14,128537,128537,14]")}getGraphemeBreakType(e){if(e<32)return 10===e?3:13===e?2:4;if(e<127)return 0;const t=this._data,n=t.length/3;let r=1;for(;r<=n;)if(et[3*r+1]))return t[3*r+2];r=2*r+1}return 0}}class z{static{this.ambiguousCharacterData=new i.d((()=>JSON.parse('{"_common":[8232,32,8233,32,5760,32,8192,32,8193,32,8194,32,8195,32,8196,32,8197,32,8198,32,8200,32,8201,32,8202,32,8287,32,8199,32,8239,32,2042,95,65101,95,65102,95,65103,95,8208,45,8209,45,8210,45,65112,45,1748,45,8259,45,727,45,8722,45,10134,45,11450,45,1549,44,1643,44,8218,44,184,44,42233,44,894,59,2307,58,2691,58,1417,58,1795,58,1796,58,5868,58,65072,58,6147,58,6153,58,8282,58,1475,58,760,58,42889,58,8758,58,720,58,42237,58,451,33,11601,33,660,63,577,63,2429,63,5038,63,42731,63,119149,46,8228,46,1793,46,1794,46,42510,46,68176,46,1632,46,1776,46,42232,46,1373,96,65287,96,8219,96,8242,96,1370,96,1523,96,8175,96,65344,96,900,96,8189,96,8125,96,8127,96,8190,96,697,96,884,96,712,96,714,96,715,96,756,96,699,96,701,96,700,96,702,96,42892,96,1497,96,2036,96,2037,96,5194,96,5836,96,94033,96,94034,96,65339,91,10088,40,10098,40,12308,40,64830,40,65341,93,10089,41,10099,41,12309,41,64831,41,10100,123,119060,123,10101,125,65342,94,8270,42,1645,42,8727,42,66335,42,5941,47,8257,47,8725,47,8260,47,9585,47,10187,47,10744,47,119354,47,12755,47,12339,47,11462,47,20031,47,12035,47,65340,92,65128,92,8726,92,10189,92,10741,92,10745,92,119311,92,119355,92,12756,92,20022,92,12034,92,42872,38,708,94,710,94,5869,43,10133,43,66203,43,8249,60,10094,60,706,60,119350,60,5176,60,5810,60,5120,61,11840,61,12448,61,42239,61,8250,62,10095,62,707,62,119351,62,5171,62,94015,62,8275,126,732,126,8128,126,8764,126,65372,124,65293,45,120784,50,120794,50,120804,50,120814,50,120824,50,130034,50,42842,50,423,50,1000,50,42564,50,5311,50,42735,50,119302,51,120785,51,120795,51,120805,51,120815,51,120825,51,130035,51,42923,51,540,51,439,51,42858,51,11468,51,1248,51,94011,51,71882,51,120786,52,120796,52,120806,52,120816,52,120826,52,130036,52,5070,52,71855,52,120787,53,120797,53,120807,53,120817,53,120827,53,130037,53,444,53,71867,53,120788,54,120798,54,120808,54,120818,54,120828,54,130038,54,11474,54,5102,54,71893,54,119314,55,120789,55,120799,55,120809,55,120819,55,120829,55,130039,55,66770,55,71878,55,2819,56,2538,56,2666,56,125131,56,120790,56,120800,56,120810,56,120820,56,120830,56,130040,56,547,56,546,56,66330,56,2663,57,2920,57,2541,57,3437,57,120791,57,120801,57,120811,57,120821,57,120831,57,130041,57,42862,57,11466,57,71884,57,71852,57,71894,57,9082,97,65345,97,119834,97,119886,97,119938,97,119990,97,120042,97,120094,97,120146,97,120198,97,120250,97,120302,97,120354,97,120406,97,120458,97,593,97,945,97,120514,97,120572,97,120630,97,120688,97,120746,97,65313,65,119808,65,119860,65,119912,65,119964,65,120016,65,120068,65,120120,65,120172,65,120224,65,120276,65,120328,65,120380,65,120432,65,913,65,120488,65,120546,65,120604,65,120662,65,120720,65,5034,65,5573,65,42222,65,94016,65,66208,65,119835,98,119887,98,119939,98,119991,98,120043,98,120095,98,120147,98,120199,98,120251,98,120303,98,120355,98,120407,98,120459,98,388,98,5071,98,5234,98,5551,98,65314,66,8492,66,119809,66,119861,66,119913,66,120017,66,120069,66,120121,66,120173,66,120225,66,120277,66,120329,66,120381,66,120433,66,42932,66,914,66,120489,66,120547,66,120605,66,120663,66,120721,66,5108,66,5623,66,42192,66,66178,66,66209,66,66305,66,65347,99,8573,99,119836,99,119888,99,119940,99,119992,99,120044,99,120096,99,120148,99,120200,99,120252,99,120304,99,120356,99,120408,99,120460,99,7428,99,1010,99,11429,99,43951,99,66621,99,128844,67,71922,67,71913,67,65315,67,8557,67,8450,67,8493,67,119810,67,119862,67,119914,67,119966,67,120018,67,120174,67,120226,67,120278,67,120330,67,120382,67,120434,67,1017,67,11428,67,5087,67,42202,67,66210,67,66306,67,66581,67,66844,67,8574,100,8518,100,119837,100,119889,100,119941,100,119993,100,120045,100,120097,100,120149,100,120201,100,120253,100,120305,100,120357,100,120409,100,120461,100,1281,100,5095,100,5231,100,42194,100,8558,68,8517,68,119811,68,119863,68,119915,68,119967,68,120019,68,120071,68,120123,68,120175,68,120227,68,120279,68,120331,68,120383,68,120435,68,5024,68,5598,68,5610,68,42195,68,8494,101,65349,101,8495,101,8519,101,119838,101,119890,101,119942,101,120046,101,120098,101,120150,101,120202,101,120254,101,120306,101,120358,101,120410,101,120462,101,43826,101,1213,101,8959,69,65317,69,8496,69,119812,69,119864,69,119916,69,120020,69,120072,69,120124,69,120176,69,120228,69,120280,69,120332,69,120384,69,120436,69,917,69,120492,69,120550,69,120608,69,120666,69,120724,69,11577,69,5036,69,42224,69,71846,69,71854,69,66182,69,119839,102,119891,102,119943,102,119995,102,120047,102,120099,102,120151,102,120203,102,120255,102,120307,102,120359,102,120411,102,120463,102,43829,102,42905,102,383,102,7837,102,1412,102,119315,70,8497,70,119813,70,119865,70,119917,70,120021,70,120073,70,120125,70,120177,70,120229,70,120281,70,120333,70,120385,70,120437,70,42904,70,988,70,120778,70,5556,70,42205,70,71874,70,71842,70,66183,70,66213,70,66853,70,65351,103,8458,103,119840,103,119892,103,119944,103,120048,103,120100,103,120152,103,120204,103,120256,103,120308,103,120360,103,120412,103,120464,103,609,103,7555,103,397,103,1409,103,119814,71,119866,71,119918,71,119970,71,120022,71,120074,71,120126,71,120178,71,120230,71,120282,71,120334,71,120386,71,120438,71,1292,71,5056,71,5107,71,42198,71,65352,104,8462,104,119841,104,119945,104,119997,104,120049,104,120101,104,120153,104,120205,104,120257,104,120309,104,120361,104,120413,104,120465,104,1211,104,1392,104,5058,104,65320,72,8459,72,8460,72,8461,72,119815,72,119867,72,119919,72,120023,72,120179,72,120231,72,120283,72,120335,72,120387,72,120439,72,919,72,120494,72,120552,72,120610,72,120668,72,120726,72,11406,72,5051,72,5500,72,42215,72,66255,72,731,105,9075,105,65353,105,8560,105,8505,105,8520,105,119842,105,119894,105,119946,105,119998,105,120050,105,120102,105,120154,105,120206,105,120258,105,120310,105,120362,105,120414,105,120466,105,120484,105,618,105,617,105,953,105,8126,105,890,105,120522,105,120580,105,120638,105,120696,105,120754,105,1110,105,42567,105,1231,105,43893,105,5029,105,71875,105,65354,106,8521,106,119843,106,119895,106,119947,106,119999,106,120051,106,120103,106,120155,106,120207,106,120259,106,120311,106,120363,106,120415,106,120467,106,1011,106,1112,106,65322,74,119817,74,119869,74,119921,74,119973,74,120025,74,120077,74,120129,74,120181,74,120233,74,120285,74,120337,74,120389,74,120441,74,42930,74,895,74,1032,74,5035,74,5261,74,42201,74,119844,107,119896,107,119948,107,120000,107,120052,107,120104,107,120156,107,120208,107,120260,107,120312,107,120364,107,120416,107,120468,107,8490,75,65323,75,119818,75,119870,75,119922,75,119974,75,120026,75,120078,75,120130,75,120182,75,120234,75,120286,75,120338,75,120390,75,120442,75,922,75,120497,75,120555,75,120613,75,120671,75,120729,75,11412,75,5094,75,5845,75,42199,75,66840,75,1472,108,8739,73,9213,73,65512,73,1633,108,1777,73,66336,108,125127,108,120783,73,120793,73,120803,73,120813,73,120823,73,130033,73,65321,73,8544,73,8464,73,8465,73,119816,73,119868,73,119920,73,120024,73,120128,73,120180,73,120232,73,120284,73,120336,73,120388,73,120440,73,65356,108,8572,73,8467,108,119845,108,119897,108,119949,108,120001,108,120053,108,120105,73,120157,73,120209,73,120261,73,120313,73,120365,73,120417,73,120469,73,448,73,120496,73,120554,73,120612,73,120670,73,120728,73,11410,73,1030,73,1216,73,1493,108,1503,108,1575,108,126464,108,126592,108,65166,108,65165,108,1994,108,11599,73,5825,73,42226,73,93992,73,66186,124,66313,124,119338,76,8556,76,8466,76,119819,76,119871,76,119923,76,120027,76,120079,76,120131,76,120183,76,120235,76,120287,76,120339,76,120391,76,120443,76,11472,76,5086,76,5290,76,42209,76,93974,76,71843,76,71858,76,66587,76,66854,76,65325,77,8559,77,8499,77,119820,77,119872,77,119924,77,120028,77,120080,77,120132,77,120184,77,120236,77,120288,77,120340,77,120392,77,120444,77,924,77,120499,77,120557,77,120615,77,120673,77,120731,77,1018,77,11416,77,5047,77,5616,77,5846,77,42207,77,66224,77,66321,77,119847,110,119899,110,119951,110,120003,110,120055,110,120107,110,120159,110,120211,110,120263,110,120315,110,120367,110,120419,110,120471,110,1400,110,1404,110,65326,78,8469,78,119821,78,119873,78,119925,78,119977,78,120029,78,120081,78,120185,78,120237,78,120289,78,120341,78,120393,78,120445,78,925,78,120500,78,120558,78,120616,78,120674,78,120732,78,11418,78,42208,78,66835,78,3074,111,3202,111,3330,111,3458,111,2406,111,2662,111,2790,111,3046,111,3174,111,3302,111,3430,111,3664,111,3792,111,4160,111,1637,111,1781,111,65359,111,8500,111,119848,111,119900,111,119952,111,120056,111,120108,111,120160,111,120212,111,120264,111,120316,111,120368,111,120420,111,120472,111,7439,111,7441,111,43837,111,959,111,120528,111,120586,111,120644,111,120702,111,120760,111,963,111,120532,111,120590,111,120648,111,120706,111,120764,111,11423,111,4351,111,1413,111,1505,111,1607,111,126500,111,126564,111,126596,111,65259,111,65260,111,65258,111,65257,111,1726,111,64428,111,64429,111,64427,111,64426,111,1729,111,64424,111,64425,111,64423,111,64422,111,1749,111,3360,111,4125,111,66794,111,71880,111,71895,111,66604,111,1984,79,2534,79,2918,79,12295,79,70864,79,71904,79,120782,79,120792,79,120802,79,120812,79,120822,79,130032,79,65327,79,119822,79,119874,79,119926,79,119978,79,120030,79,120082,79,120134,79,120186,79,120238,79,120290,79,120342,79,120394,79,120446,79,927,79,120502,79,120560,79,120618,79,120676,79,120734,79,11422,79,1365,79,11604,79,4816,79,2848,79,66754,79,42227,79,71861,79,66194,79,66219,79,66564,79,66838,79,9076,112,65360,112,119849,112,119901,112,119953,112,120005,112,120057,112,120109,112,120161,112,120213,112,120265,112,120317,112,120369,112,120421,112,120473,112,961,112,120530,112,120544,112,120588,112,120602,112,120646,112,120660,112,120704,112,120718,112,120762,112,120776,112,11427,112,65328,80,8473,80,119823,80,119875,80,119927,80,119979,80,120031,80,120083,80,120187,80,120239,80,120291,80,120343,80,120395,80,120447,80,929,80,120504,80,120562,80,120620,80,120678,80,120736,80,11426,80,5090,80,5229,80,42193,80,66197,80,119850,113,119902,113,119954,113,120006,113,120058,113,120110,113,120162,113,120214,113,120266,113,120318,113,120370,113,120422,113,120474,113,1307,113,1379,113,1382,113,8474,81,119824,81,119876,81,119928,81,119980,81,120032,81,120084,81,120188,81,120240,81,120292,81,120344,81,120396,81,120448,81,11605,81,119851,114,119903,114,119955,114,120007,114,120059,114,120111,114,120163,114,120215,114,120267,114,120319,114,120371,114,120423,114,120475,114,43847,114,43848,114,7462,114,11397,114,43905,114,119318,82,8475,82,8476,82,8477,82,119825,82,119877,82,119929,82,120033,82,120189,82,120241,82,120293,82,120345,82,120397,82,120449,82,422,82,5025,82,5074,82,66740,82,5511,82,42211,82,94005,82,65363,115,119852,115,119904,115,119956,115,120008,115,120060,115,120112,115,120164,115,120216,115,120268,115,120320,115,120372,115,120424,115,120476,115,42801,115,445,115,1109,115,43946,115,71873,115,66632,115,65331,83,119826,83,119878,83,119930,83,119982,83,120034,83,120086,83,120138,83,120190,83,120242,83,120294,83,120346,83,120398,83,120450,83,1029,83,1359,83,5077,83,5082,83,42210,83,94010,83,66198,83,66592,83,119853,116,119905,116,119957,116,120009,116,120061,116,120113,116,120165,116,120217,116,120269,116,120321,116,120373,116,120425,116,120477,116,8868,84,10201,84,128872,84,65332,84,119827,84,119879,84,119931,84,119983,84,120035,84,120087,84,120139,84,120191,84,120243,84,120295,84,120347,84,120399,84,120451,84,932,84,120507,84,120565,84,120623,84,120681,84,120739,84,11430,84,5026,84,42196,84,93962,84,71868,84,66199,84,66225,84,66325,84,119854,117,119906,117,119958,117,120010,117,120062,117,120114,117,120166,117,120218,117,120270,117,120322,117,120374,117,120426,117,120478,117,42911,117,7452,117,43854,117,43858,117,651,117,965,117,120534,117,120592,117,120650,117,120708,117,120766,117,1405,117,66806,117,71896,117,8746,85,8899,85,119828,85,119880,85,119932,85,119984,85,120036,85,120088,85,120140,85,120192,85,120244,85,120296,85,120348,85,120400,85,120452,85,1357,85,4608,85,66766,85,5196,85,42228,85,94018,85,71864,85,8744,118,8897,118,65366,118,8564,118,119855,118,119907,118,119959,118,120011,118,120063,118,120115,118,120167,118,120219,118,120271,118,120323,118,120375,118,120427,118,120479,118,7456,118,957,118,120526,118,120584,118,120642,118,120700,118,120758,118,1141,118,1496,118,71430,118,43945,118,71872,118,119309,86,1639,86,1783,86,8548,86,119829,86,119881,86,119933,86,119985,86,120037,86,120089,86,120141,86,120193,86,120245,86,120297,86,120349,86,120401,86,120453,86,1140,86,11576,86,5081,86,5167,86,42719,86,42214,86,93960,86,71840,86,66845,86,623,119,119856,119,119908,119,119960,119,120012,119,120064,119,120116,119,120168,119,120220,119,120272,119,120324,119,120376,119,120428,119,120480,119,7457,119,1121,119,1309,119,1377,119,71434,119,71438,119,71439,119,43907,119,71919,87,71910,87,119830,87,119882,87,119934,87,119986,87,120038,87,120090,87,120142,87,120194,87,120246,87,120298,87,120350,87,120402,87,120454,87,1308,87,5043,87,5076,87,42218,87,5742,120,10539,120,10540,120,10799,120,65368,120,8569,120,119857,120,119909,120,119961,120,120013,120,120065,120,120117,120,120169,120,120221,120,120273,120,120325,120,120377,120,120429,120,120481,120,5441,120,5501,120,5741,88,9587,88,66338,88,71916,88,65336,88,8553,88,119831,88,119883,88,119935,88,119987,88,120039,88,120091,88,120143,88,120195,88,120247,88,120299,88,120351,88,120403,88,120455,88,42931,88,935,88,120510,88,120568,88,120626,88,120684,88,120742,88,11436,88,11613,88,5815,88,42219,88,66192,88,66228,88,66327,88,66855,88,611,121,7564,121,65369,121,119858,121,119910,121,119962,121,120014,121,120066,121,120118,121,120170,121,120222,121,120274,121,120326,121,120378,121,120430,121,120482,121,655,121,7935,121,43866,121,947,121,8509,121,120516,121,120574,121,120632,121,120690,121,120748,121,1199,121,4327,121,71900,121,65337,89,119832,89,119884,89,119936,89,119988,89,120040,89,120092,89,120144,89,120196,89,120248,89,120300,89,120352,89,120404,89,120456,89,933,89,978,89,120508,89,120566,89,120624,89,120682,89,120740,89,11432,89,1198,89,5033,89,5053,89,42220,89,94019,89,71844,89,66226,89,119859,122,119911,122,119963,122,120015,122,120067,122,120119,122,120171,122,120223,122,120275,122,120327,122,120379,122,120431,122,120483,122,7458,122,43923,122,71876,122,66293,90,71909,90,65338,90,8484,90,8488,90,119833,90,119885,90,119937,90,119989,90,120041,90,120197,90,120249,90,120301,90,120353,90,120405,90,120457,90,918,90,120493,90,120551,90,120609,90,120667,90,120725,90,5059,90,42204,90,71849,90,65282,34,65284,36,65285,37,65286,38,65290,42,65291,43,65294,46,65295,47,65296,48,65297,49,65298,50,65299,51,65300,52,65301,53,65302,54,65303,55,65304,56,65305,57,65308,60,65309,61,65310,62,65312,64,65316,68,65318,70,65319,71,65324,76,65329,81,65330,82,65333,85,65334,86,65335,87,65343,95,65346,98,65348,100,65350,102,65355,107,65357,109,65358,110,65361,113,65362,114,65364,116,65365,117,65367,119,65370,122,65371,123,65373,125,119846,109],"_default":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"cs":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"de":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"es":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"fr":[65374,126,65306,58,65281,33,8216,96,8245,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"it":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ja":[8211,45,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65292,44,65307,59],"ko":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pl":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pt-BR":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"qps-ploc":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ru":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,305,105,921,73,1009,112,215,120,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"tr":[160,32,8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"zh-hans":[65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65288,40,65289,41],"zh-hant":[8211,45,65374,126,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65307,59]}')))}static{this.cache=new r.o5({getCacheKey:JSON.stringify},(e=>{function t(e){const t=new Map;for(let n=0;n!e.startsWith("_")&&e in r));0===s.length&&(s=["_default"]);for(const a of s){i=n(i,t(r[a]))}const o=function(e,t){const n=new Map(e);for(const[r,i]of t)n.set(r,i);return n}(t(r._common),i);return new z(o)}))}static getInstance(e){return z.cache.get(Array.from(e))}static{this._locales=new i.d((()=>Object.keys(z.ambiguousCharacterData.value).filter((e=>!e.startsWith("_")))))}static getLocales(){return z._locales.value}constructor(e){this.confusableDictionary=e}isAmbiguous(e){return this.confusableDictionary.has(e)}getPrimaryConfusable(e){return this.confusableDictionary.get(e)}getConfusableCodePoints(){return new Set(this.confusableDictionary.keys())}}class j{static getRawData(){return JSON.parse("[9,10,11,12,13,32,127,160,173,847,1564,4447,4448,6068,6069,6155,6156,6157,6158,7355,7356,8192,8193,8194,8195,8196,8197,8198,8199,8200,8201,8202,8203,8204,8205,8206,8207,8234,8235,8236,8237,8238,8239,8287,8288,8289,8290,8291,8292,8293,8294,8295,8296,8297,8298,8299,8300,8301,8302,8303,10240,12288,12644,65024,65025,65026,65027,65028,65029,65030,65031,65032,65033,65034,65035,65036,65037,65038,65039,65279,65440,65520,65521,65522,65523,65524,65525,65526,65527,65528,65532,78844,119155,119156,119157,119158,119159,119160,119161,119162,917504,917505,917506,917507,917508,917509,917510,917511,917512,917513,917514,917515,917516,917517,917518,917519,917520,917521,917522,917523,917524,917525,917526,917527,917528,917529,917530,917531,917532,917533,917534,917535,917536,917537,917538,917539,917540,917541,917542,917543,917544,917545,917546,917547,917548,917549,917550,917551,917552,917553,917554,917555,917556,917557,917558,917559,917560,917561,917562,917563,917564,917565,917566,917567,917568,917569,917570,917571,917572,917573,917574,917575,917576,917577,917578,917579,917580,917581,917582,917583,917584,917585,917586,917587,917588,917589,917590,917591,917592,917593,917594,917595,917596,917597,917598,917599,917600,917601,917602,917603,917604,917605,917606,917607,917608,917609,917610,917611,917612,917613,917614,917615,917616,917617,917618,917619,917620,917621,917622,917623,917624,917625,917626,917627,917628,917629,917630,917631,917760,917761,917762,917763,917764,917765,917766,917767,917768,917769,917770,917771,917772,917773,917774,917775,917776,917777,917778,917779,917780,917781,917782,917783,917784,917785,917786,917787,917788,917789,917790,917791,917792,917793,917794,917795,917796,917797,917798,917799,917800,917801,917802,917803,917804,917805,917806,917807,917808,917809,917810,917811,917812,917813,917814,917815,917816,917817,917818,917819,917820,917821,917822,917823,917824,917825,917826,917827,917828,917829,917830,917831,917832,917833,917834,917835,917836,917837,917838,917839,917840,917841,917842,917843,917844,917845,917846,917847,917848,917849,917850,917851,917852,917853,917854,917855,917856,917857,917858,917859,917860,917861,917862,917863,917864,917865,917866,917867,917868,917869,917870,917871,917872,917873,917874,917875,917876,917877,917878,917879,917880,917881,917882,917883,917884,917885,917886,917887,917888,917889,917890,917891,917892,917893,917894,917895,917896,917897,917898,917899,917900,917901,917902,917903,917904,917905,917906,917907,917908,917909,917910,917911,917912,917913,917914,917915,917916,917917,917918,917919,917920,917921,917922,917923,917924,917925,917926,917927,917928,917929,917930,917931,917932,917933,917934,917935,917936,917937,917938,917939,917940,917941,917942,917943,917944,917945,917946,917947,917948,917949,917950,917951,917952,917953,917954,917955,917956,917957,917958,917959,917960,917961,917962,917963,917964,917965,917966,917967,917968,917969,917970,917971,917972,917973,917974,917975,917976,917977,917978,917979,917980,917981,917982,917983,917984,917985,917986,917987,917988,917989,917990,917991,917992,917993,917994,917995,917996,917997,917998,917999]")}static{this._data=void 0}static getData(){return this._data||(this._data=new Set(j.getRawData())),this._data}static isInvisibleCharacter(e){return j.getData().has(e)}static get codePoints(){return j.getData()}}},1646:(e,t,n)=>{"use strict";n.d(t,{Fd:()=>h});var r=n(9861),i=n(1234),s=n(631),o=n(8209),a=n(4001),l=n(8748),c=n(6359);const h={Configuration:"base.contributions.configuration"},u={properties:{},patternProperties:{}},d={properties:{},patternProperties:{}},g={properties:{},patternProperties:{}},f={properties:{},patternProperties:{}},m={properties:{},patternProperties:{}},p={properties:{},patternProperties:{}},b="vscode://schemas/settings/resourceLanguage",_=c.O.as(l.F.JSONContribution);const k="\\[([^\\]]+)\\]",v=new RegExp(k,"g"),C=`^(${k})+$`,y=new RegExp(C);function L(e){const t=[];if(y.test(e)){let n=v.exec(e);for(;n?.length;){const r=n[1].trim();r&&t.push(r),n=v.exec(e)}}return(0,r.dM)(t)}const w=new class{constructor(){this.registeredConfigurationDefaults=[],this.overrideIdentifiers=new Set,this._onDidSchemaChange=new i.vl,this._onDidUpdateConfiguration=new i.vl,this.configurationDefaultsOverrides=new Map,this.defaultLanguageConfigurationOverridesNode={id:"defaultOverrides",title:o.kg("defaultLanguageConfigurationOverrides.title","Default Language Configuration Overrides"),properties:{}},this.configurationContributors=[this.defaultLanguageConfigurationOverridesNode],this.resourceLanguageSettingsSchema={properties:{},patternProperties:{},additionalProperties:!0,allowTrailingCommas:!0,allowComments:!0},this.configurationProperties={},this.policyConfigurations=new Map,this.excludedConfigurationProperties={},_.registerSchema(b,this.resourceLanguageSettingsSchema),this.registerOverridePropertyPatternKey()}registerConfiguration(e,t=!0){this.registerConfigurations([e],t)}registerConfigurations(e,t=!0){const n=new Set;this.doRegisterConfigurations(e,t,n),_.registerSchema(b,this.resourceLanguageSettingsSchema),this._onDidSchemaChange.fire(),this._onDidUpdateConfiguration.fire({properties:n})}registerDefaultConfigurations(e){const t=new Set;this.doRegisterDefaultConfigurations(e,t),this._onDidSchemaChange.fire(),this._onDidUpdateConfiguration.fire({properties:t,defaultsOverrides:!0})}doRegisterDefaultConfigurations(e,t){this.registeredConfigurationDefaults.push(...e);const n=[];for(const{overrides:r,source:i}of e)for(const e in r){t.add(e);const s=this.configurationDefaultsOverrides.get(e)??this.configurationDefaultsOverrides.set(e,{configurationDefaultOverrides:[]}).get(e),o=r[e];if(s.configurationDefaultOverrides.push({value:o,source:i}),y.test(e)){const t=this.mergeDefaultConfigurationsForOverrideIdentifier(e,o,i,s.configurationDefaultOverrideValue);if(!t)continue;s.configurationDefaultOverrideValue=t,this.updateDefaultOverrideProperty(e,t,i),n.push(...L(e))}else{const t=this.mergeDefaultConfigurationsForConfigurationProperty(e,o,i,s.configurationDefaultOverrideValue);if(!t)continue;s.configurationDefaultOverrideValue=t;const n=this.configurationProperties[e];n&&(this.updatePropertyDefaultValue(e,n),this.updateSchema(e,n))}}this.doRegisterOverrideIdentifiers(n)}updateDefaultOverrideProperty(e,t,n){const r={type:"object",default:t.value,description:o.kg("defaultLanguageConfiguration.description","Configure settings to be overridden for the {0} language.",(0,a.Mo)(e)),$ref:b,defaultDefaultValue:t.value,source:n,defaultValueSource:n};this.configurationProperties[e]=r,this.defaultLanguageConfigurationOverridesNode.properties[e]=r}mergeDefaultConfigurationsForOverrideIdentifier(e,t,n,r){const i=r?.value||{},o=r?.source??new Map;if(o instanceof Map){for(const e of Object.keys(t)){const r=t[e];if(s.Gv(r)&&(s.b0(i[e])||s.Gv(i[e]))){if(i[e]={...i[e]??{},...r},n)for(const t in r)o.set(`${e}.${t}`,n)}else i[e]=r,n?o.set(e,n):o.delete(e)}return{value:i,source:o}}console.error("objectConfigurationSources is not a Map")}mergeDefaultConfigurationsForConfigurationProperty(e,t,n,r){const i=this.configurationProperties[e],o=r?.value??i?.defaultDefaultValue;let a=n;if(s.Gv(t)&&(void 0!==i&&"object"===i.type||void 0===i&&(s.b0(o)||s.Gv(o)))){if(a=r?.source??new Map,!(a instanceof Map))return void console.error("defaultValueSource is not a Map");for(const r in t)n&&a.set(`${e}.${r}`,n);t={...s.Gv(o)?o:{},...t}}return{value:t,source:a}}registerOverrideIdentifiers(e){this.doRegisterOverrideIdentifiers(e),this._onDidSchemaChange.fire()}doRegisterOverrideIdentifiers(e){for(const t of e)this.overrideIdentifiers.add(t);this.updateOverridePropertyPatternKey()}doRegisterConfigurations(e,t,n){e.forEach((e=>{this.validateAndRegisterProperties(e,t,e.extensionInfo,e.restrictedProperties,void 0,n),this.configurationContributors.push(e),this.registerJSONConfiguration(e)}))}validateAndRegisterProperties(e,t=!0,n,r,i=3,o){i=s.z(e.scope)?i:e.scope;const a=e.properties;if(a)for(const c in a){const e=a[c];t&&S(c,e)?delete a[c]:(e.source=n,e.defaultDefaultValue=a[c].default,this.updatePropertyDefaultValue(c,e),y.test(c)?e.scope=void 0:(e.scope=s.z(e.scope)?i:e.scope,e.restricted=s.z(e.restricted)?!!r?.includes(c):e.restricted),!a[c].hasOwnProperty("included")||a[c].included?(this.configurationProperties[c]=a[c],a[c].policy?.name&&this.policyConfigurations.set(a[c].policy.name,c),!a[c].deprecationMessage&&a[c].markdownDeprecationMessage&&(a[c].deprecationMessage=a[c].markdownDeprecationMessage),o.add(c)):(this.excludedConfigurationProperties[c]=a[c],delete a[c]))}const l=e.allOf;if(l)for(const s of l)this.validateAndRegisterProperties(s,t,n,r,i,o)}getConfigurationProperties(){return this.configurationProperties}getPolicyConfigurations(){return this.policyConfigurations}registerJSONConfiguration(e){const t=e=>{const n=e.properties;if(n)for(const t in n)this.updateSchema(t,n[t]);const r=e.allOf;r?.forEach(t)};t(e)}updateSchema(e,t){switch(u.properties[e]=t,t.scope){case 1:d.properties[e]=t;break;case 2:g.properties[e]=t;break;case 6:f.properties[e]=t;break;case 3:m.properties[e]=t;break;case 4:p.properties[e]=t;break;case 5:p.properties[e]=t,this.resourceLanguageSettingsSchema.properties[e]=t}}updateOverridePropertyPatternKey(){for(const e of this.overrideIdentifiers.values()){const t=`[${e}]`,n={type:"object",description:o.kg("overrideSettings.defaultDescription","Configure editor settings to be overridden for a language."),errorMessage:o.kg("overrideSettings.errorMessage","This setting does not support per-language configuration."),$ref:b};this.updatePropertyDefaultValue(t,n),u.properties[t]=n,d.properties[t]=n,g.properties[t]=n,f.properties[t]=n,m.properties[t]=n,p.properties[t]=n}}registerOverridePropertyPatternKey(){const e={type:"object",description:o.kg("overrideSettings.defaultDescription","Configure editor settings to be overridden for a language."),errorMessage:o.kg("overrideSettings.errorMessage","This setting does not support per-language configuration."),$ref:b};u.patternProperties[C]=e,d.patternProperties[C]=e,g.patternProperties[C]=e,f.patternProperties[C]=e,m.patternProperties[C]=e,p.patternProperties[C]=e,this._onDidSchemaChange.fire()}updatePropertyDefaultValue(e,t){const n=this.configurationDefaultsOverrides.get(e)?.configurationDefaultOverrideValue;let r,i;!n||t.disallowConfigurationDefault&&n.source||(r=n.value,i=n.source),s.b0(r)&&(r=t.defaultDefaultValue,i=void 0),s.b0(r)&&(r=function(e){switch(Array.isArray(e)?e[0]:e){case"boolean":return!1;case"integer":case"number":return 0;case"string":return"";case"array":return[];case"object":return{};default:return null}}(t.type)),t.default=r,t.defaultValueSource=i}};function S(e,t){return e.trim()?y.test(e)?o.kg("config.property.languageDefault","Cannot register '{0}'. This matches property pattern '\\\\[.*\\\\]$' for describing language specific editor settings. Use 'configurationDefaults' contribution.",e):void 0!==w.getConfigurationProperties()[e]?o.kg("config.property.duplicate","Cannot register '{0}'. This property is already registered.",e):t.policy?.name&&void 0!==w.getPolicyConfigurations().get(t.policy?.name)?o.kg("config.policy.duplicate","Cannot register '{0}'. The associated policy {1} is already registered with {2}.",e,t.policy?.name,w.getPolicyConfigurations().get(t.policy?.name)):null:o.kg("config.property.empty","Cannot register an empty property")}c.O.add(h.Configuration,w)},1674:(e,t,n)=>{"use strict";n.d(t,{$l:()=>a,Gs:()=>d,MB:()=>o,Sw:()=>h,bb:()=>c,gN:()=>l,pJ:()=>u});var r=n(1090);const i="undefined"!==typeof Buffer;new r.d((()=>new Uint8Array(256)));let s;class o{static wrap(e){return i&&!Buffer.isBuffer(e)&&(e=Buffer.from(e.buffer,e.byteOffset,e.byteLength)),new o(e)}constructor(e){this.buffer=e,this.byteLength=this.buffer.byteLength}toString(){return i?this.buffer.toString():(s||(s=new TextDecoder),s.decode(this.buffer))}}function a(e,t){return(e[t+0]|0)>>>0|e[t+1]<<8>>>0}function l(e,t,n){e[n+0]=255&t,t>>>=8,e[n+1]=255&t}function c(e,t){return e[t]*2**24+65536*e[t+1]+256*e[t+2]+e[t+3]}function h(e,t,n){e[n+3]=t,t>>>=8,e[n+2]=t,t>>>=8,e[n+1]=t,t>>>=8,e[n]=t}function u(e,t){return e[t]}function d(e,t,n){e[n]=t}},1773:(e,t,n)=>{"use strict";n.r(t),n.d(t,{DefaultModelSHA1Computer:()=>yi,ModelService:()=>Ci});var r=n(1234),i=n(1484),s=n(8067),o=n(9861),a=n(7661),l=n(4383),c=n(1508),h=n(9400),u=n(4454);class d{static _nextVisibleColumn(e,t,n){return 9===e?d.nextRenderTabStop(t,n):c.ne(e)||c.Ss(e)?t+2:t+1}static visibleColumnFromColumn(e,t,n){const r=Math.min(t-1,e.length),i=e.substring(0,r),s=new c.km(i);let o=0;for(;!s.eol();){const e=c.Z5(i,r,s.offset);s.nextGraphemeLength(),o=this._nextVisibleColumn(e,o,n)}return o}static columnFromVisibleColumn(e,t,n){if(t<=0)return 1;const r=e.length,i=new c.km(e);let s=0,o=1;for(;!i.eol();){const a=c.Z5(e,r,i.offset);i.nextGraphemeLength();const l=this._nextVisibleColumn(a,s,n),h=i.offset+1;if(l>=t){return l-t \n\t"}constructor(e){if(e.autoClosingPairs?this._autoClosingPairs=e.autoClosingPairs.map((e=>new C(e))):e.brackets?this._autoClosingPairs=e.brackets.map((e=>new C({open:e[0],close:e[1]}))):this._autoClosingPairs=[],e.__electricCharacterSupport&&e.__electricCharacterSupport.docComment){const t=e.__electricCharacterSupport.docComment;this._autoClosingPairs.push(new C({open:t.open,close:t.close||""}))}this._autoCloseBeforeForQuotes="string"===typeof e.autoCloseBefore?e.autoCloseBefore:w.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_QUOTES,this._autoCloseBeforeForBrackets="string"===typeof e.autoCloseBefore?e.autoCloseBefore:w.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_BRACKETS,this._surroundingPairs=e.surroundingPairs||this._autoClosingPairs}getAutoClosingPairs(){return this._autoClosingPairs}getAutoCloseBeforeSet(e){return e?this._autoCloseBeforeForQuotes:this._autoCloseBeforeForBrackets}getSurroundingPairs(){return this._surroundingPairs}}function S(e){return 0!==(3&e)}var x=n(1674);let E,N,T;function A(){return E||(E=new TextDecoder("UTF-16LE")),E}function I(){return T||(T=s.cm()?A():(N||(N=new TextDecoder("UTF-16BE")),N)),T}function O(e,t,n){const r=new Uint16Array(e.buffer,t,n);return n>0&&(65279===r[0]||65534===r[0])?function(e,t,n){const r=[];let i=0;for(let s=0;s[e[0].toLowerCase(),e[1].toLowerCase()]));const n=[];for(let o=0;o{const[n,r]=e,[i,s]=t;return n===i||n===s||r===i||r===s},i=(e,r)=>{const i=Math.min(e,r),s=Math.max(e,r);for(let o=0;o0&&s.push({open:r,close:i})}return s}(t);this.brackets=n.map(((t,r)=>new M(e,r,t.open,t.close,function(e,t,n,r){let i=[];i=i.concat(e),i=i.concat(t);for(let s=0,o=i.length;s=0&&r.push(t);for(const t of s.close)t.indexOf(e)>=0&&r.push(t)}}function B(e,t){return e.length-t.length}function F(e){if(e.length<=1)return e;const t=[],n=new Set;for(const r of e)n.has(r)||(t.push(r),n.add(r));return t}function P(e){const t=/^[\w ]+$/.test(e);return e=c.bm(e),t?`\\b${e}\\b`:e}function V(e,t){const n=`(${e.map(P).join(")|(")})`;return c.OS(n,!0,t)}const z=function(){let e=null,t=null;return function(n){return e!==n&&(e=n,t=function(e){const t=new Uint16Array(e.length);let n=0;for(let r=e.length-1;r>=0;r--)t[n++]=e.charCodeAt(r);return I().decode(t)}(e)),t}}();class j{static _findPrevBracketInText(e,t,n,r){const i=n.match(e);if(!i)return null;const s=n.length-(i.index||0),o=i[0].length,a=r+s;return new m.Q(t,a-o+1,t,a+1)}static findPrevBracketInRange(e,t,n,r,i){const s=z(n).substring(n.length-i,n.length-r);return this._findPrevBracketInText(e,t,s,r)}static findNextBracketInText(e,t,n,r){const i=n.match(e);if(!i)return null;const s=i.index||0,o=i[0].length;if(0===o)return null;const a=r+s;return new m.Q(t,a+1,t,a+1+o)}static findNextBracketInRange(e,t,n,r,i){const s=n.substring(r,i);return this.findNextBracketInText(e,t,s,r)}}class q{constructor(e){this._richEditBrackets=e}getElectricCharacters(){const e=[];if(this._richEditBrackets)for(const t of this._richEditBrackets.brackets)for(const n of t.close){const t=n.charAt(n.length-1);e.push(t)}return(0,o.dM)(e)}onElectricCharacter(e,t,n){if(!this._richEditBrackets||0===this._richEditBrackets.brackets.length)return null;const r=t.findTokenIndexAtOffset(n-1);if(S(t.getStandardTokenType(r)))return null;const i=this._richEditBrackets.reversedRegex,s=t.getLineContent().substring(0,n-1)+e,o=j.findPrevBracketInRange(i,1,s,0,s.length);if(!o)return null;const a=s.substring(o.startColumn-1,o.endColumn-1).toLowerCase();if(this._richEditBrackets.textIsOpenBracket[a])return null;const l=t.getActualLineContentBefore(o.startColumn-1);return/^\s*$/.test(l)?{matchOpenBracket:a}:null}}function W(e){return e.global&&(e.lastIndex=0),!0}class U{constructor(e){this._indentationRules=e}shouldIncrease(e){return!!(this._indentationRules&&this._indentationRules.increaseIndentPattern&&W(this._indentationRules.increaseIndentPattern)&&this._indentationRules.increaseIndentPattern.test(e))}shouldDecrease(e){return!!(this._indentationRules&&this._indentationRules.decreaseIndentPattern&&W(this._indentationRules.decreaseIndentPattern)&&this._indentationRules.decreaseIndentPattern.test(e))}shouldIndentNextLine(e){return!!(this._indentationRules&&this._indentationRules.indentNextLinePattern&&W(this._indentationRules.indentNextLinePattern)&&this._indentationRules.indentNextLinePattern.test(e))}shouldIgnore(e){return!!(this._indentationRules&&this._indentationRules.unIndentedLinePattern&&W(this._indentationRules.unIndentedLinePattern)&&this._indentationRules.unIndentedLinePattern.test(e))}getIndentMetadata(e){let t=0;return this.shouldIncrease(e)&&(t+=1),this.shouldDecrease(e)&&(t+=2),this.shouldIndentNextLine(e)&&(t+=4),this.shouldIgnore(e)&&(t+=8),t}}class ${constructor(e){(e=e||{}).brackets=e.brackets||[["(",")"],["{","}"],["[","]"]],this._brackets=[],e.brackets.forEach((e=>{const t=$._createOpenBracketRegExp(e[0]),n=$._createCloseBracketRegExp(e[1]);t&&n&&this._brackets.push({open:e[0],openRegExp:t,close:e[1],closeRegExp:n})})),this._regExpRules=e.onEnterRules||[]}onEnter(e,t,n,r){if(e>=3)for(let i=0,s=this._regExpRules.length;i!e.reg||(e.reg.lastIndex=0,e.reg.test(e.text)))))return e.action}if(e>=2&&n.length>0&&r.length>0)for(let i=0,s=this._brackets.length;i=2&&n.length>0)for(let i=0,s=this._brackets.length;i{const t=new Set;return{info:new ee(this,e,t),closing:t}})),i=new J.VV((e=>{const t=new Set,n=new Set;return{info:new te(this,e,t,n),opening:t,openingColorized:n}}));for(const[o,a]of n){const e=r.get(o),t=i.get(a);e.closing.add(t.info),t.opening.add(e.info)}const s=t.colorizedBracketPairs?Y(t.colorizedBracketPairs):n.filter((e=>!("<"===e[0]&&">"===e[1])));for(const[o,a]of s){const e=r.get(o),t=i.get(a);e.closing.add(t.info),t.openingColorized.add(e.info),t.opening.add(e.info)}this._openingBrackets=new Map([...r.cachedValues].map((([e,t])=>[e,t.info]))),this._closingBrackets=new Map([...i.cachedValues].map((([e,t])=>[e,t.info])))}get openingBrackets(){return[...this._openingBrackets.values()]}get closingBrackets(){return[...this._closingBrackets.values()]}getOpeningBracketInfo(e){return this._openingBrackets.get(e)}getClosingBracketInfo(e){return this._closingBrackets.get(e)}getBracketInfo(e){return this.getOpeningBracketInfo(e)||this.getClosingBracketInfo(e)}getBracketRegExp(e){return V(Array.from([...this._openingBrackets.keys(),...this._closingBrackets.keys()]),e)}}function Y(e){return e.filter((([e,t])=>""!==e&&""!==t))}class Z{constructor(e,t){this.config=e,this.bracketText=t}get languageId(){return this.config.languageId}}class ee extends Z{constructor(e,t,n){super(e,t),this.openedBrackets=n,this.isOpeningBracket=!0}}class te extends Z{constructor(e,t,n,r){super(e,t),this.openingBrackets=n,this.openingColorizedBrackets=r,this.isOpeningBracket=!1}closes(e){return e.config===this.config&&this.openingBrackets.has(e)}closesColorized(e){return e.config===this.config&&this.openingColorizedBrackets.has(e)}getOpeningBrackets(){return[...this.openingBrackets]}}var ne=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},re=function(e,t){return function(n,r){t(n,r,e)}};class ie{constructor(e){this.languageId=e}affects(e){return!this.languageId||this.languageId===e}}const se=(0,H.u1)("languageConfigurationService");let oe=class extends i.jG{constructor(e,t){super(),this.configurationService=e,this.languageService=t,this._registry=this._register(new ge),this.onDidChangeEmitter=this._register(new r.vl),this.onDidChange=this.onDidChangeEmitter.event,this.configurations=new Map;const n=new Set(Object.values(ae));this._register(this.configurationService.onDidChangeConfiguration((e=>{const t=e.change.keys.some((e=>n.has(e))),r=e.change.overrides.filter((([e,t])=>t.some((e=>n.has(e))))).map((([e])=>e));if(t)this.configurations.clear(),this.onDidChangeEmitter.fire(new ie(void 0));else for(const n of r)this.languageService.isRegisteredLanguageId(n)&&(this.configurations.delete(n),this.onDidChangeEmitter.fire(new ie(n)))}))),this._register(this._registry.onDidChange((e=>{this.configurations.delete(e.languageId),this.onDidChangeEmitter.fire(new ie(e.languageId))})))}register(e,t,n){return this._registry.register(e,t,n)}getLanguageConfiguration(e){let t=this.configurations.get(e);return t||(t=function(e,t,n,r){let i=t.getLanguageConfiguration(e);if(!i){if(!r.isRegisteredLanguageId(e))return new fe(e,{});i=new fe(e,{})}const s=function(e,t){const n=t.getValue(ae.brackets,{overrideIdentifier:e}),r=t.getValue(ae.colorizedBracketPairs,{overrideIdentifier:e});return{brackets:le(n),colorizedBracketPairs:le(r)}}(i.languageId,n),o=he([i.underlyingConfig,s]);return new fe(i.languageId,o)}(e,this._registry,this.configurationService,this.languageService),this.configurations.set(e,t)),t}};oe=ne([re(0,K.pG),re(1,k.L)],oe);const ae={brackets:"editor.language.brackets",colorizedBracketPairs:"editor.language.colorizedBracketPairs"};function le(e){if(Array.isArray(e))return e.map((e=>{if(Array.isArray(e)&&2===e.length)return[e[0],e[1]]})).filter((e=>!!e))}class ce{constructor(e){this.languageId=e,this._resolved=null,this._entries=[],this._order=0,this._resolved=null}register(e,t){const n=new ue(e,t,++this._order);return this._entries.push(n),this._resolved=null,(0,i.s)((()=>{for(let e=0;ee.configuration))))}}function he(e){let t={comments:void 0,brackets:void 0,wordPattern:void 0,indentationRules:void 0,onEnterRules:void 0,autoClosingPairs:void 0,surroundingPairs:void 0,autoCloseBefore:void 0,folding:void 0,colorizedBracketPairs:void 0,__electricCharacterSupport:void 0};for(const n of e)t={comments:n.comments||t.comments,brackets:n.brackets||t.brackets,wordPattern:n.wordPattern||t.wordPattern,indentationRules:n.indentationRules||t.indentationRules,onEnterRules:n.onEnterRules||t.onEnterRules,autoClosingPairs:n.autoClosingPairs||t.autoClosingPairs,surroundingPairs:n.surroundingPairs||t.surroundingPairs,autoCloseBefore:n.autoCloseBefore||t.autoCloseBefore,folding:n.folding||t.folding,colorizedBracketPairs:n.colorizedBracketPairs||t.colorizedBracketPairs,__electricCharacterSupport:n.__electricCharacterSupport||t.__electricCharacterSupport};return t}class ue{constructor(e,t,n){this.configuration=e,this.priority=t,this.order=n}static cmp(e,t){return e.priority===t.priority?e.order-t.order:e.priority-t.priority}}class de{constructor(e){this.languageId=e}}class ge extends i.jG{constructor(){super(),this._entries=new Map,this._onDidChange=this._register(new r.vl),this.onDidChange=this._onDidChange.event,this._register(this.register(Q.vH,{brackets:[["(",")"],["[","]"],["{","}"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],colorizedBracketPairs:[],folding:{offSide:!0}},0))}register(e,t,n=0){let r=this._entries.get(e);r||(r=new ce(e),this._entries.set(e,r));const s=r.register(t,n);return this._onDidChange.fire(new de(e)),(0,i.s)((()=>{s.dispose(),this._onDidChange.fire(new de(e))}))}getLanguageConfiguration(e){const t=this._entries.get(e);return t?.getResolvedConfiguration()||null}}class fe{constructor(e,t){this.languageId=e,this.underlyingConfig=t,this._brackets=null,this._electricCharacter=null,this._onEnterSupport=this.underlyingConfig.brackets||this.underlyingConfig.indentationRules||this.underlyingConfig.onEnterRules?new $(this.underlyingConfig):null,this.comments=fe._handleComments(this.underlyingConfig),this.characterPair=new w(this.underlyingConfig),this.wordDefinition=this.underlyingConfig.wordPattern||v.Ld,this.indentationRules=this.underlyingConfig.indentationRules,this.underlyingConfig.indentationRules?this.indentRulesSupport=new U(this.underlyingConfig.indentationRules):this.indentRulesSupport=null,this.foldingRules=this.underlyingConfig.folding||{},this.bracketsNew=new X(e,this.underlyingConfig)}getWordDefinition(){return(0,v.Io)(this.wordDefinition)}get brackets(){return!this._brackets&&this.underlyingConfig.brackets&&(this._brackets=new R(this.languageId,this.underlyingConfig.brackets)),this._brackets}get electricCharacter(){return this._electricCharacter||(this._electricCharacter=new q(this.brackets)),this._electricCharacter}onEnter(e,t,n,r){return this._onEnterSupport?this._onEnterSupport.onEnter(e,t,n,r):null}getAutoClosingPairs(){return new y(this.characterPair.getAutoClosingPairs())}getAutoCloseBeforeSet(e){return this.characterPair.getAutoCloseBeforeSet(e)}getSurroundingPairs(){return this.characterPair.getSurroundingPairs()}static _handleComments(e){const t=e.comments;if(!t)return null;const n={};if(t.lineComment&&(n.lineCommentToken=t.lineComment),t.blockComment){const[e,r]=t.blockComment;n.blockCommentStartToken=e,n.blockCommentEndToken=r}return n}}(0,G.v)(se,oe,1);var me=n(6223);class pe{constructor(e,t,n,r){this.range=e,this.nestingLevel=t,this.nestingLevelOfEqualBracketType=n,this.isInvalid=r}}class be{constructor(e,t,n,r,i,s){this.range=e,this.openingBracketRange=t,this.closingBracketRange=n,this.nestingLevel=r,this.nestingLevelOfEqualBracketType=i,this.bracketPairNode=s}get openingBracketInfo(){return this.bracketPairNode.openingBracket.bracketInfo}}class _e extends be{constructor(e,t,n,r,i,s,o){super(e,t,n,r,i,s),this.minVisibleColumnIndentation=o}}var ke=n(973);function ve(e){return 0===e}const Ce=2**26;function ye(e,t){return e*Ce+t}function Le(e){const t=e,n=Math.floor(t/Ce),r=t-n*Ce;return new ke.W(n,r)}function we(e,t){let n=e+t;return t>=Ce&&(n-=e%Ce),n}function Se(e,t){return e.reduce(((e,n)=>we(e,t(n))),0)}function xe(e,t){return e===t}function Ee(e,t){const n=e,r=t;if(r-n<=0)return 0;const i=Math.floor(n/Ce),s=Math.floor(r/Ce),o=r-s*Ce;if(i===s){return ye(0,o-(n-i*Ce))}return ye(s-i,o)}function Ne(e,t){return e=t}function Ie(e){return ye(e.lineNumber-1,e.column-1)}function Oe(e,t){const n=e,r=Math.floor(n/Ce),i=n-r*Ce,s=t,o=Math.floor(s/Ce),a=s-o*Ce;return new m.Q(r+1,i+1,o+1,a+1)}class Me{static fromModelContentChanges(e){return e.map((e=>{const t=m.Q.lift(e.range);return new Me(Ie(t.getStartPosition()),Ie(t.getEndPosition()),function(e){const t=(0,c.uz)(e);return ye(t.length-1,t[t.length-1].length)}(e.text))})).reverse()}constructor(e,t,n){this.startOffset=e,this.endOffset=t,this.newLength=n}toString(){return`[${Le(this.startOffset)}...${Le(this.endOffset)}) -> ${Le(this.newLength)}`}}class Re{constructor(e){this.nextEditIdx=0,this.deltaOldToNewLineCount=0,this.deltaOldToNewColumnCount=0,this.deltaLineIdxInOld=-1,this.edits=e.map((e=>De.from(e)))}getOffsetBeforeChange(e){return this.adjustNextEdit(e),this.translateCurToOld(e)}getDistanceToNextChange(e){this.adjustNextEdit(e);const t=this.edits[this.nextEditIdx],n=t?this.translateOldToCur(t.offsetObj):null;return null===n?null:Ee(e,n)}translateOldToCur(e){return e.lineCount===this.deltaLineIdxInOld?ye(e.lineCount+this.deltaOldToNewLineCount,e.columnCount+this.deltaOldToNewColumnCount):ye(e.lineCount+this.deltaOldToNewLineCount,e.columnCount)}translateCurToOld(e){const t=Le(e);return t.lineCount-this.deltaOldToNewLineCount===this.deltaLineIdxInOld?ye(t.lineCount-this.deltaOldToNewLineCount,t.columnCount-this.deltaOldToNewColumnCount):ye(t.lineCount-this.deltaOldToNewLineCount,t.columnCount)}adjustNextEdit(e){for(;this.nextEditIdx>5;if(0===r){const e=1<e};class Ve{constructor(){this.items=new Map}getKey(e){let t=this.items.get(e);return void 0===t&&(t=this.items.size,this.items.set(e,t)),t}}class ze{get length(){return this._length}constructor(e){this._length=e}}class je extends ze{static create(e,t,n){let r=e.length;return t&&(r=we(r,t.length)),n&&(r=we(r,n.length)),new je(r,e,t,n,t?t.missingOpeningBracketIds:Fe.getEmpty())}get kind(){return 2}get listHeight(){return 0}get childrenLength(){return 3}getChild(e){switch(e){case 0:return this.openingBracket;case 1:return this.child;case 2:return this.closingBracket}throw new Error("Invalid child index")}get children(){const e=[];return e.push(this.openingBracket),this.child&&e.push(this.child),this.closingBracket&&e.push(this.closingBracket),e}constructor(e,t,n,r,i){super(e),this.openingBracket=t,this.child=n,this.closingBracket=r,this.missingOpeningBracketIds=i}canBeReused(e){return null!==this.closingBracket&&!e.intersects(this.missingOpeningBracketIds)}deepClone(){return new je(this.length,this.openingBracket.deepClone(),this.child&&this.child.deepClone(),this.closingBracket&&this.closingBracket.deepClone(),this.missingOpeningBracketIds)}computeMinIndentation(e,t){return this.child?this.child.computeMinIndentation(we(e,this.openingBracket.length),t):Number.MAX_SAFE_INTEGER}}class qe extends ze{static create23(e,t,n,r=!1){let i=e.length,s=e.missingOpeningBracketIds;if(e.listHeight!==t.listHeight)throw new Error("Invalid list heights");if(i=we(i,t.length),s=s.merge(t.missingOpeningBracketIds),n){if(e.listHeight!==n.listHeight)throw new Error("Invalid list heights");i=we(i,n.length),s=s.merge(n.missingOpeningBracketIds)}return r?new Ue(i,e.listHeight+1,e,t,n,s):new We(i,e.listHeight+1,e,t,n,s)}static getEmpty(){return new He(0,0,[],Fe.getEmpty())}get kind(){return 4}get missingOpeningBracketIds(){return this._missingOpeningBracketIds}constructor(e,t,n){super(e),this.listHeight=t,this._missingOpeningBracketIds=n,this.cachedMinIndentation=-1}throwIfImmutable(){}makeLastElementMutable(){this.throwIfImmutable();const e=this.childrenLength;if(0===e)return;const t=this.getChild(e-1),n=4===t.kind?t.toMutable():t;return t!==n&&this.setChild(e-1,n),n}makeFirstElementMutable(){this.throwIfImmutable();if(0===this.childrenLength)return;const e=this.getChild(0),t=4===e.kind?e.toMutable():e;return e!==t&&this.setChild(0,t),t}canBeReused(e){if(e.intersects(this.missingOpeningBracketIds))return!1;if(0===this.childrenLength)return!1;let t=this;for(;4===t.kind;){const e=t.childrenLength;if(0===e)throw new l.D7;t=t.getChild(e-1)}return t.canBeReused(e)}handleChildrenChanged(){this.throwIfImmutable();const e=this.childrenLength;let t=this.getChild(0).length,n=this.getChild(0).missingOpeningBracketIds;for(let r=1;rthis.textBufferLineCount-1||this.lineIdx===this.textBufferLineCount-1&&this.lineCharOffset>=this.textBufferLastLineLength)return null;null===this.line&&(this.lineTokens=this.textModel.tokenization.getLineTokens(this.lineIdx+1),this.line=this.lineTokens.getLineContent(),this.lineTokenOffset=0===this.lineCharOffset?0:this.lineTokens.findTokenIndexAtOffset(this.lineCharOffset));const e=this.lineIdx,t=this.lineCharOffset;let n=0;for(;;){const r=this.lineTokens,i=r.getCount();let s=null;if(this.lineTokenOffset1e3)break}if(n>1500)break}const r=(i=e,s=t,o=this.lineIdx,a=this.lineCharOffset,i!==o?ye(o-i,a):ye(0,a-s));var i,s,o,a;return new Ze(r,0,-1,Fe.getEmpty(),new Qe(r))}}class nt{constructor(e,t){this.text=e,this._offset=0,this.idx=0;const n=t.getRegExpStr(),r=n?new RegExp(n+"|\n","gi"):null,i=[];let s,o=0,a=0,l=0,c=0;const h=[];for(let g=0;g<60;g++)h.push(new Ze(ye(0,g),0,-1,Fe.getEmpty(),new Qe(ye(0,g))));const u=[];for(let g=0;g<60;g++)u.push(new Ze(ye(1,g),0,-1,Fe.getEmpty(),new Qe(ye(1,g))));if(r)for(r.lastIndex=0;null!==(s=r.exec(e));){const e=s.index,n=s[0];if("\n"===n)o++,a=e+1;else{if(l!==e){let t;if(c===o){const n=e-l;if(nfunction(e){let t=(0,c.bm)(e);/^[\w ]+/.test(e)&&(t=`\\b${t}`);/[\w ]+$/.test(e)&&(t=`${t}\\b`);return t}(e))).join("|")}}get regExpGlobal(){if(!this.hasRegExp){const e=this.getRegExpStr();this._regExpGlobal=e?new RegExp(e,"gi"):null,this.hasRegExp=!0}return this._regExpGlobal}getToken(e){return this.map.get(e.toLowerCase())}findClosingTokenText(e){for(const[t,n]of this.map)if(2===n.kind&&n.bracketIds.intersects(e))return t}get isEmpty(){return 0===this.map.size}}class it{constructor(e,t){this.denseKeyProvider=e,this.getLanguageConfiguration=t,this.languageIdToBracketTokens=new Map}didLanguageChange(e){return this.languageIdToBracketTokens.has(e)}getSingleLanguageBracketTokens(e){let t=this.languageIdToBracketTokens.get(e);return t||(t=rt.createFromLanguage(this.getLanguageConfiguration(e),this.denseKeyProvider),this.languageIdToBracketTokens.set(e,t)),t}}function st(e,t=!1){if(0===e.length)return null;if(1===e.length)return e[0];let n=e.length;for(;n>3;){const r=n>>1;for(let i=0;i=3?e[2]:null,t)}function ot(e,t){return Math.abs(e.listHeight-t.listHeight)}function at(e,t){return e.listHeight===t.listHeight?qe.create23(e,t,null,!1):e.listHeight>t.listHeight?function(e,t){let n=e=e.toMutable();const r=[];let i;for(;;){if(t.listHeight===n.listHeight){i=t;break}if(4!==n.kind)throw new Error("unexpected");r.push(n),n=n.makeLastElementMutable()}for(let s=r.length-1;s>=0;s--){const e=r[s];i?e.childrenLength>=3?i=qe.create23(e.unappendChild(),i,null,!1):(e.appendChildOfSameHeight(i),i=void 0):e.handleChildrenChanged()}return i?qe.create23(e,i,null,!1):e}(e,t):function(e,t){let n=e=e.toMutable();const r=[];for(;t.listHeight!==n.listHeight;){if(4!==n.kind)throw new Error("unexpected");r.push(n),n=n.makeFirstElementMutable()}let i=t;for(let s=r.length-1;s>=0;s--){const e=r[s];i?e.childrenLength>=3?i=qe.create23(i,e.unprependChild(),null,!1):(e.prependChildOfSameHeight(i),i=void 0):e.handleChildrenChanged()}return i?qe.create23(i,e,null,!1):e}(t,e)}class lt{constructor(e){this.lastOffset=0,this.nextNodes=[e],this.offsets=[0],this.idxs=[]}readLongestNodeAt(e,t){if(Ne(e,this.lastOffset))throw new Error("Invalid offset");for(this.lastOffset=e;;){const n=ht(this.nextNodes);if(!n)return;const r=ht(this.offsets);if(Ne(e,r))return;if(Ne(r,e))if(we(r,n.length)<=e)this.nextNodeAfterCurrent();else{const e=ct(n);-1!==e?(this.nextNodes.push(n.getChild(e)),this.offsets.push(r),this.idxs.push(e)):this.nextNodeAfterCurrent()}else{if(t(n))return this.nextNodeAfterCurrent(),n;{const e=ct(n);if(-1===e)return void this.nextNodeAfterCurrent();this.nextNodes.push(n.getChild(e)),this.offsets.push(r),this.idxs.push(e)}}}}nextNodeAfterCurrent(){for(;;){const e=ht(this.offsets),t=ht(this.nextNodes);if(this.nextNodes.pop(),this.offsets.pop(),0===this.idxs.length)break;const n=ht(this.nextNodes),r=ct(n,this.idxs[this.idxs.length-1]);if(-1!==r){this.nextNodes.push(n.getChild(r)),this.offsets.push(we(e,t.length)),this.idxs[this.idxs.length-1]=r;break}this.idxs.pop()}}}function ct(e,t=-1){for(;;){if(++t>=e.childrenLength)return-1;if(e.getChild(t))return t}}function ht(e){return e.length>0?e[e.length-1]:void 0}function ut(e,t,n,r){return new dt(e,t,n,r).parseDocument()}class dt{constructor(e,t,n,r){if(this.tokenizer=e,this.createImmutableLists=r,this._itemsConstructed=0,this._itemsFromCache=0,n&&r)throw new Error("Not supported");this.oldNodeReader=n?new lt(n):void 0,this.positionMapper=new Re(t)}parseDocument(){this._itemsConstructed=0,this._itemsFromCache=0;let e=this.parseList(Fe.getEmpty(),0);return e||(e=qe.getEmpty()),e}parseList(e,t){const n=[];for(;;){let r=this.tryReadChildFromCache(e);if(!r){const n=this.tokenizer.peek();if(!n||2===n.kind&&n.bracketIds.intersects(e))break;r=this.parseChild(e,t+1)}4===r.kind&&0===r.childrenLength||n.push(r)}const r=this.oldNodeReader?function(e){if(0===e.length)return null;if(1===e.length)return e[0];let t=0;function n(){if(t>=e.length)return null;const n=t,r=e[n].listHeight;for(t++;t=2?st(0===n&&t===e.length?e:e.slice(n,t),!1):e[n]}let r=n(),i=n();if(!i)return r;for(let s=n();s;s=n())ot(r,i)<=ot(i,s)?(r=at(r,i),i=s):i=at(i,s);return at(r,i)}(n):st(n,this.createImmutableLists);return r}tryReadChildFromCache(e){if(this.oldNodeReader){const t=this.positionMapper.getDistanceToNextChange(this.tokenizer.offset);if(null===t||!ve(t)){const n=this.oldNodeReader.readLongestNodeAt(this.positionMapper.getOffsetBeforeChange(this.tokenizer.offset),(n=>{if(null!==t&&!Ne(n.length,t))return!1;return n.canBeReused(e)}));if(n)return this._itemsFromCache++,this.tokenizer.skip(n.length),n}}}parseChild(e,t){this._itemsConstructed++;const n=this.tokenizer.read();switch(n.kind){case 2:return new Xe(n.bracketIds,n.length);case 0:return n.astNode;case 1:{if(t>300)return new Qe(n.length);const r=e.merge(n.bracketIds),i=this.parseList(r,t+1),s=this.tokenizer.peek();return s&&2===s.kind&&(s.bracketId===n.bracketId||s.bracketIds.intersects(n.bracketIds))?(this.tokenizer.read(),je.create(n.astNode,i,s.astNode)):je.create(n.astNode,i,null)}default:throw new Error("unexpected")}}}function gt(e,t){if(0===e.length)return t;if(0===t.length)return e;const n=new o.j3(mt(e)),r=mt(t);r.push({modified:!1,lengthBefore:void 0,lengthAfter:void 0});let i=n.dequeue();function s(e){if(void 0===e){const e=n.takeWhile((e=>!0))||[];return i&&e.unshift(i),e}const t=[];for(;i&&!ve(e);){const[r,s]=i.splitAt(e);t.push(r),e=Ee(r.lengthAfter,e),i=s??n.dequeue()}return ve(e)||t.push(new ft(!1,e,e)),t}const a=[];function l(e,t,n){if(a.length>0&&xe(a[a.length-1].endOffset,e)){const e=a[a.length-1];a[a.length-1]=new Me(e.startOffset,t,we(e.newLength,n))}else a.push({startOffset:e,endOffset:t,newLength:n})}let c=0;for(const o of r){const e=s(o.lengthBefore);if(o.modified){const t=we(c,Se(e,(e=>e.lengthBefore)));l(c,t,o.lengthAfter),c=t}else for(const t of e){const e=c;c=we(c,t.lengthBefore),t.modified&&l(e,c,t.lengthAfter)}}return a}class ft{constructor(e,t,n){this.modified=e,this.lengthBefore=t,this.lengthAfter=n}splitAt(e){const t=Ee(e,this.lengthAfter);return xe(t,0)?[this,void 0]:this.modified?[new ft(this.modified,this.lengthBefore,e),new ft(this.modified,0,t)]:[new ft(this.modified,e,e),new ft(this.modified,t,t)]}toString(){return`${this.modified?"M":"U"}:${Le(this.lengthBefore)} -> ${Le(this.lengthAfter)}`}}function mt(e){const t=[];let n=0;for(const r of e){const e=Ee(n,r.startOffset);ve(e)||t.push(new ft(!1,e,e));const i=Ee(r.startOffset,r.endOffset);t.push(new ft(!0,i,r.newLength)),n=r.endOffset}return t}class pt extends i.jG{didLanguageChange(e){return this.brackets.didLanguageChange(e)}constructor(e,t){if(super(),this.textModel=e,this.getLanguageConfiguration=t,this.didChangeEmitter=new r.vl,this.denseKeyProvider=new Ve,this.brackets=new it(this.denseKeyProvider,this.getLanguageConfiguration),this.onDidChange=this.didChangeEmitter.event,this.queuedTextEditsForInitialAstWithoutTokens=[],this.queuedTextEdits=[],e.tokenization.hasTokens)2===e.tokenization.backgroundTokenizationState?(this.initialAstWithoutTokens=void 0,this.astWithTokens=this.parseDocumentFromTextBuffer([],void 0,!1)):(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer([],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens);else{const e=this.brackets.getSingleLanguageBracketTokens(this.textModel.getLanguageId()),t=new nt(this.textModel.getValue(),e);this.initialAstWithoutTokens=ut(t,[],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens}}handleDidChangeBackgroundTokenizationState(){if(2===this.textModel.tokenization.backgroundTokenizationState){const e=void 0===this.initialAstWithoutTokens;this.initialAstWithoutTokens=void 0,e||this.didChangeEmitter.fire()}}handleDidChangeTokens({ranges:e}){const t=e.map((e=>new Me(ye(e.fromLineNumber-1,0),ye(e.toLineNumber,0),ye(e.toLineNumber-e.fromLineNumber+1,0))));this.handleEdits(t,!0),this.initialAstWithoutTokens||this.didChangeEmitter.fire()}handleContentChanged(e){const t=Me.fromModelContentChanges(e.changes);this.handleEdits(t,!1)}handleEdits(e,t){const n=gt(this.queuedTextEdits,e);this.queuedTextEdits=n,this.initialAstWithoutTokens&&!t&&(this.queuedTextEditsForInitialAstWithoutTokens=gt(this.queuedTextEditsForInitialAstWithoutTokens,e))}flushQueue(){this.queuedTextEdits.length>0&&(this.astWithTokens=this.parseDocumentFromTextBuffer(this.queuedTextEdits,this.astWithTokens,!1),this.queuedTextEdits=[]),this.queuedTextEditsForInitialAstWithoutTokens.length>0&&(this.initialAstWithoutTokens&&(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer(this.queuedTextEditsForInitialAstWithoutTokens,this.initialAstWithoutTokens,!1)),this.queuedTextEditsForInitialAstWithoutTokens=[])}parseDocumentFromTextBuffer(e,t,n){const r=t;return ut(new et(this.textModel,this.brackets),e,r,n)}getBracketsInRange(e,t){this.flushQueue();const n=ye(e.startLineNumber-1,e.startColumn-1),r=ye(e.endLineNumber-1,e.endColumn-1);return new o.c1((e=>{const i=this.initialAstWithoutTokens||this.astWithTokens;kt(i,0,i.length,n,r,e,0,0,new Map,t)}))}getBracketPairsInRange(e,t){this.flushQueue();const n=Ie(e.getStartPosition()),r=Ie(e.getEndPosition());return new o.c1((e=>{const i=this.initialAstWithoutTokens||this.astWithTokens,s=new vt(e,t,this.textModel);Ct(i,0,i.length,n,r,s,0,new Map)}))}getFirstBracketAfter(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return _t(t,0,t.length,Ie(e))}getFirstBracketBefore(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return bt(t,0,t.length,Ie(e))}}function bt(e,t,n,r){if(4===e.kind||2===e.kind){const i=[];for(const r of e.children)n=we(t,r.length),i.push({nodeOffsetStart:t,nodeOffsetEnd:n}),t=n;for(let t=i.length-1;t>=0;t--){const{nodeOffsetStart:n,nodeOffsetEnd:s}=i[t];if(Ne(n,r)){const i=bt(e.children[t],n,s,r);if(i)return i}}return null}if(3===e.kind)return null;if(1===e.kind){const r=Oe(t,n);return{bracketInfo:e.bracketInfo,range:r}}return null}function _t(e,t,n,r){if(4===e.kind||2===e.kind){for(const i of e.children){if(Ne(r,n=we(t,i.length))){const e=_t(i,t,n,r);if(e)return e}t=n}return null}if(3===e.kind)return null;if(1===e.kind){const r=Oe(t,n);return{bracketInfo:e.bracketInfo,range:r}}return null}function kt(e,t,n,r,i,s,o,a,l,c,h=!1){if(o>200)return!0;e:for(;;)switch(e.kind){case 4:{const a=e.childrenLength;for(let h=0;h200)return!0;let l=!0;if(2===e.kind){let c=0;if(a){let t=a.get(e.openingBracket.text);void 0===t&&(t=0),c=t,t++,a.set(e.openingBracket.text,t)}const h=we(t,e.openingBracket.length);let u=-1;if(s.includeMinIndentation&&(u=e.computeMinIndentation(t,s.textModel)),l=s.push(new _e(Oe(t,n),Oe(t,h),e.closingBracket?Oe(we(h,e.child?.length||0),n):void 0,o,c,e,u)),t=h,l&&e.child){const c=e.child;if(n=we(t,c.length),Te(t,i)&&Ae(n,r)&&(l=Ct(c,t,n,r,i,s,o+1,a),!l))return!1}a?.set(e.openingBracket.text,c)}else{let n=t;for(const t of e.children){const e=n;if(n=we(n,t.length),Te(e,i)&&Te(r,n)&&(l=Ct(t,e,n,r,i,s,o,a),!l))return!1}}return l}class yt extends i.jG{get canBuildAST(){return this.textModel.getValueLength()<=5e6}constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t,this.bracketPairsTree=this._register(new i.HE),this.onDidChangeEmitter=new r.vl,this.onDidChange=this.onDidChangeEmitter.event,this.bracketsRequested=!1}handleLanguageConfigurationServiceChange(e){e.languageId&&!this.bracketPairsTree.value?.object.didLanguageChange(e.languageId)||(this.bracketPairsTree.clear(),this.updateBracketPairsTree())}handleDidChangeOptions(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeLanguage(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeContent(e){this.bracketPairsTree.value?.object.handleContentChanged(e)}handleDidChangeBackgroundTokenizationState(){this.bracketPairsTree.value?.object.handleDidChangeBackgroundTokenizationState()}handleDidChangeTokens(e){this.bracketPairsTree.value?.object.handleDidChangeTokens(e)}updateBracketPairsTree(){if(this.bracketsRequested&&this.canBuildAST){if(!this.bracketPairsTree.value){const n=new i.Cm;this.bracketPairsTree.value=(e=n.add(new pt(this.textModel,(e=>this.languageConfigurationService.getLanguageConfiguration(e)))),t=n,{object:e,dispose:()=>t?.dispose()}),n.add(this.bracketPairsTree.value.object.onDidChange((e=>this.onDidChangeEmitter.fire(e)))),this.onDidChangeEmitter.fire()}}else this.bracketPairsTree.value&&(this.bracketPairsTree.clear(),this.onDidChangeEmitter.fire());var e,t}getBracketPairsInRange(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!1)||o.c1.empty}getBracketPairsInRangeWithMinIndentation(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!0)||o.c1.empty}getBracketsInRange(e,t=!1){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketsInRange(e,t)||o.c1.empty}findMatchingBracketUp(e,t,n){const r=this.textModel.validatePosition(t),i=this.textModel.getLanguageIdAtPosition(r.lineNumber,r.column);if(this.canBuildAST){const n=this.languageConfigurationService.getLanguageConfiguration(i).bracketsNew.getClosingBracketInfo(e);if(!n)return null;const r=this.getBracketPairsInRange(m.Q.fromPositions(t,t)).findLast((e=>n.closes(e.openingBracketInfo)));return r?r.openingBracketRange:null}{const t=e.toLowerCase(),s=this.languageConfigurationService.getLanguageConfiguration(i).brackets;if(!s)return null;const o=s.textIsBracket[t];return o?St(this._findMatchingBracketUp(o,r,Lt(n))):null}}matchBracket(e,t){if(this.canBuildAST){const t=this.getBracketPairsInRange(m.Q.fromPositions(e,e)).filter((t=>void 0!==t.closingBracketRange&&(t.openingBracketRange.containsPosition(e)||t.closingBracketRange.containsPosition(e)))).findLastMaxBy((0,o.VE)((t=>t.openingBracketRange.containsPosition(e)?t.openingBracketRange:t.closingBracketRange),m.Q.compareRangesUsingStarts));return t?[t.openingBracketRange,t.closingBracketRange]:null}{const n=Lt(t);return this._matchBracket(this.textModel.validatePosition(e),n)}}_establishBracketSearchOffsets(e,t,n,r){const i=t.getCount(),s=t.getLanguageId(r);let o=Math.max(0,e.column-1-n.maxBracketLength);for(let l=r-1;l>=0;l--){const e=t.getEndOffset(l);if(e<=o)break;if(S(t.getStandardTokenType(l))||t.getLanguageId(l)!==s){o=e;break}}let a=Math.min(t.getLineContent().length,e.column-1+n.maxBracketLength);for(let l=r+1;l=a)break;if(S(t.getStandardTokenType(l))||t.getLanguageId(l)!==s){a=e;break}}return{searchStartOffset:o,searchEndOffset:a}}_matchBracket(e,t){const n=e.lineNumber,r=this.textModel.tokenization.getLineTokens(n),i=this.textModel.getLineContent(n),s=r.findTokenIndexAtOffset(e.column-1);if(s<0)return null;const o=this.languageConfigurationService.getLanguageConfiguration(r.getLanguageId(s)).brackets;if(o&&!S(r.getStandardTokenType(s))){let{searchStartOffset:a,searchEndOffset:l}=this._establishBracketSearchOffsets(e,r,o,s),c=null;for(;;){const r=j.findNextBracketInRange(o.forwardRegex,n,i,a,l);if(!r)break;if(r.startColumn<=e.column&&e.column<=r.endColumn){const e=i.substring(r.startColumn-1,r.endColumn-1).toLowerCase(),n=this._matchFoundBracket(r,o.textIsBracket[e],o.textIsOpenBracket[e],t);if(n){if(n instanceof wt)return null;c=n}}a=r.endColumn-1}if(c)return c}if(s>0&&r.getStartOffset(s)===e.column-1){const o=s-1,a=this.languageConfigurationService.getLanguageConfiguration(r.getLanguageId(o)).brackets;if(a&&!S(r.getStandardTokenType(o))){const{searchStartOffset:s,searchEndOffset:l}=this._establishBracketSearchOffsets(e,r,a,o),c=j.findPrevBracketInRange(a.reversedRegex,n,i,s,l);if(c&&c.startColumn<=e.column&&e.column<=c.endColumn){const e=i.substring(c.startColumn-1,c.endColumn-1).toLowerCase(),n=this._matchFoundBracket(c,a.textIsBracket[e],a.textIsOpenBracket[e],t);if(n)return n instanceof wt?null:n}}}return null}_matchFoundBracket(e,t,n,r){if(!t)return null;const i=n?this._findMatchingBracketDown(t,e.getEndPosition(),r):this._findMatchingBracketUp(t,e.getStartPosition(),r);return i?i instanceof wt?i:[e,i]:null}_findMatchingBracketUp(e,t,n){const r=e.languageId,i=e.reversedRegex;let s=-1,o=0;const a=(t,r,a,l)=>{for(;;){if(n&&++o%100===0&&!n())return wt.INSTANCE;const c=j.findPrevBracketInRange(i,t,r,a,l);if(!c)break;const h=r.substring(c.startColumn-1,c.endColumn-1).toLowerCase();if(e.isOpen(h)?s++:e.isClose(h)&&s--,0===s)return c;l=c.startColumn-1}return null};for(let l=t.lineNumber;l>=1;l--){const e=this.textModel.tokenization.getLineTokens(l),n=e.getCount(),i=this.textModel.getLineContent(l);let s=n-1,o=i.length,c=i.length;l===t.lineNumber&&(s=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,c=t.column-1);let h=!0;for(;s>=0;s--){const t=e.getLanguageId(s)===r&&!S(e.getStandardTokenType(s));if(t)h?o=e.getStartOffset(s):(o=e.getStartOffset(s),c=e.getEndOffset(s));else if(h&&o!==c){const e=a(l,i,o,c);if(e)return e}h=t}if(h&&o!==c){const e=a(l,i,o,c);if(e)return e}}return null}_findMatchingBracketDown(e,t,n){const r=e.languageId,i=e.forwardRegex;let s=1,o=0;const a=(t,r,a,l)=>{for(;;){if(n&&++o%100===0&&!n())return wt.INSTANCE;const c=j.findNextBracketInRange(i,t,r,a,l);if(!c)break;const h=r.substring(c.startColumn-1,c.endColumn-1).toLowerCase();if(e.isOpen(h)?s++:e.isClose(h)&&s--,0===s)return c;a=c.endColumn-1}return null},l=this.textModel.getLineCount();for(let c=t.lineNumber;c<=l;c++){const e=this.textModel.tokenization.getLineTokens(c),n=e.getCount(),i=this.textModel.getLineContent(c);let s=0,o=0,l=0;c===t.lineNumber&&(s=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,l=t.column-1);let h=!0;for(;s=1;s--){const e=this.textModel.tokenization.getLineTokens(s),o=e.getCount(),a=this.textModel.getLineContent(s);let l=o-1,c=a.length,h=a.length;if(s===t.lineNumber){l=e.findTokenIndexAtOffset(t.column-1),c=t.column-1,h=t.column-1;const s=e.getLanguageId(l);n!==s&&(n=s,r=this.languageConfigurationService.getLanguageConfiguration(n).brackets,i=this.languageConfigurationService.getLanguageConfiguration(n).bracketsNew)}let u=!0;for(;l>=0;l--){const t=e.getLanguageId(l);if(n!==t){if(r&&i&&u&&c!==h){const e=j.findPrevBracketInRange(r.reversedRegex,s,a,c,h);if(e)return this._toFoundBracket(i,e);u=!1}n=t,r=this.languageConfigurationService.getLanguageConfiguration(n).brackets,i=this.languageConfigurationService.getLanguageConfiguration(n).bracketsNew}const o=!!r&&!S(e.getStandardTokenType(l));if(o)u?c=e.getStartOffset(l):(c=e.getStartOffset(l),h=e.getEndOffset(l));else if(i&&r&&u&&c!==h){const e=j.findPrevBracketInRange(r.reversedRegex,s,a,c,h);if(e)return this._toFoundBracket(i,e)}u=o}if(i&&r&&u&&c!==h){const e=j.findPrevBracketInRange(r.reversedRegex,s,a,c,h);if(e)return this._toFoundBracket(i,e)}}return null}findNextBracket(e){const t=this.textModel.validatePosition(e);if(this.canBuildAST)return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getFirstBracketAfter(t)||null;const n=this.textModel.getLineCount();let r=null,i=null,s=null;for(let o=t.lineNumber;o<=n;o++){const e=this.textModel.tokenization.getLineTokens(o),n=e.getCount(),a=this.textModel.getLineContent(o);let l=0,c=0,h=0;if(o===t.lineNumber){l=e.findTokenIndexAtOffset(t.column-1),c=t.column-1,h=t.column-1;const n=e.getLanguageId(l);r!==n&&(r=n,i=this.languageConfigurationService.getLanguageConfiguration(r).brackets,s=this.languageConfigurationService.getLanguageConfiguration(r).bracketsNew)}let u=!0;for(;lvoid 0!==t.closingBracketRange&&t.range.strictContainsRange(e)));return t?[t.openingBracketRange,t.closingBracketRange]:null}const r=Lt(t),i=this.textModel.getLineCount(),s=new Map;let o=[];const a=(e,t)=>{if(!s.has(e)){const n=[];for(let e=0,r=t?t.brackets.length:0;e{for(;;){if(r&&++l%100===0&&!r())return wt.INSTANCE;const a=j.findNextBracketInRange(e.forwardRegex,t,n,i,s);if(!a)break;const c=n.substring(a.startColumn-1,a.endColumn-1).toLowerCase(),h=e.textIsBracket[c];if(h&&(h.isOpen(c)?o[h.index]++:h.isClose(c)&&o[h.index]--,-1===o[h.index]))return this._matchFoundBracket(a,h,!1,r);i=a.endColumn-1}return null};let h=null,u=null;for(let d=n.lineNumber;d<=i;d++){const e=this.textModel.tokenization.getLineTokens(d),t=e.getCount(),r=this.textModel.getLineContent(d);let i=0,s=0,o=0;if(d===n.lineNumber){i=e.findTokenIndexAtOffset(n.column-1),s=n.column-1,o=n.column-1;const t=e.getLanguageId(i);h!==t&&(h=t,u=this.languageConfigurationService.getLanguageConfiguration(h).brackets,a(h,u))}let l=!0;for(;i!0;{const t=Date.now();return()=>Date.now()-t<=e}}class wt{static{this.INSTANCE=new wt}constructor(){this._searchCanceledBrand=void 0}}function St(e){return e instanceof wt?null:e}var xt=n(7119),Et=n(5724);class Nt extends i.jG{constructor(e){super(),this.textModel=e,this.colorProvider=new Tt,this.onDidChangeEmitter=new r.vl,this.onDidChange=this.onDidChangeEmitter.event,this.colorizationOptions=e.getOptions().bracketPairColorizationOptions,this._register(e.bracketPairs.onDidChange((e=>{this.onDidChangeEmitter.fire()})))}handleDidChangeOptions(e){this.colorizationOptions=this.textModel.getOptions().bracketPairColorizationOptions}getDecorationsInRange(e,t,n,r){if(r)return[];if(void 0===t)return[];if(!this.colorizationOptions.enabled)return[];return this.textModel.bracketPairs.getBracketsInRange(e,!0).map((e=>({id:`bracket${e.range.toString()}-${e.nestingLevel}`,options:{description:"BracketPairColorization",inlineClassName:this.colorProvider.getInlineClassName(e,this.colorizationOptions.independentColorPoolPerBracketType)},ownerId:0,range:e.range}))).toArray()}getAllDecorations(e,t){return void 0===e?[]:this.colorizationOptions.enabled?this.getDecorationsInRange(new m.Q(1,1,this.textModel.getLineCount(),1),e,t):[]}}class Tt{constructor(){this.unexpectedClosingBracketClassName="unexpected-closing-bracket"}getInlineClassName(e,t){return e.isInvalid?this.unexpectedClosingBracketClassName:this.getInlineClassNameOfLevel(t?e.nestingLevelOfEqualBracketType:e.nestingLevel)}getInlineClassNameOfLevel(e){return"bracket-highlighting-"+e%30}}(0,Et.zy)(((e,t)=>{const n=[xt.sN,xt.lQ,xt.ss,xt.l5,xt.sH,xt.zp],r=new Tt;t.addRule(`.monaco-editor .${r.unexpectedClosingBracketClassName} { color: ${e.getColor(xt.s7)}; }`);const i=n.map((t=>e.getColor(t))).filter((e=>!!e)).filter((e=>!e.isTransparent()));for(let s=0;s<30;s++){const e=i[s%i.length];t.addRule(`.monaco-editor .${r.getInlineClassNameOfLevel(s)} { color: ${e}; }`)}}));var At=n(8209);function It(e){return e.replace(/\n/g,"\\n").replace(/\r/g,"\\r")}class Ot{get oldLength(){return this.oldText.length}get oldEnd(){return this.oldPosition+this.oldText.length}get newLength(){return this.newText.length}get newEnd(){return this.newPosition+this.newText.length}constructor(e,t,n,r){this.oldPosition=e,this.oldText=t,this.newPosition=n,this.newText=r}toString(){return 0===this.oldText.length?`(insert@${this.oldPosition} "${It(this.newText)}")`:0===this.newText.length?`(delete@${this.oldPosition} "${It(this.oldText)}")`:`(replace@${this.oldPosition} "${It(this.oldText)}" with "${It(this.newText)}")`}static _writeStringSize(e){return 4+2*e.length}static _writeString(e,t,n){const r=t.length;x.Sw(e,r,n),n+=4;for(let i=0;i0&&(this.changes=(s=this.changes,o=t,null===s||0===s.length?o:new Mt(s,o).compress())),this.afterEOL=n,this.afterVersionId=r,this.afterCursorState=i}static _writeSelectionsSize(e){return 4+16*(e?e.length:0)}static _writeSelections(e,t,n){if(x.Sw(e,t?t.length:0,n),n+=4,t)for(const r of t)x.Sw(e,r.selectionStartLineNumber,n),n+=4,x.Sw(e,r.selectionStartColumn,n),n+=4,x.Sw(e,r.positionLineNumber,n),n+=4,x.Sw(e,r.positionColumn,n),n+=4;return n}static _readSelections(e,t,n){const r=x.bb(e,t);t+=4;for(let i=0;ie.toString())).join(", ")}matchesResource(e){return(h.r.isUri(this.model)?this.model:this.model.uri).toString()===e.toString()}setModel(e){this.model=e}canAppend(e){return this.model===e&&this._data instanceof Bt}append(e,t,n,r,i){this._data instanceof Bt&&this._data.append(e,t,n,r,i)}close(){this._data instanceof Bt&&(this._data=this._data.serialize())}open(){this._data instanceof Bt||(this._data=Bt.deserialize(this._data))}undo(){if(h.r.isUri(this.model))throw new Error("Invalid SingleModelEditStackElement");this._data instanceof Bt&&(this._data=this._data.serialize());const e=Bt.deserialize(this._data);this.model._applyUndo(e.changes,e.beforeEOL,e.beforeVersionId,e.beforeCursorState)}redo(){if(h.r.isUri(this.model))throw new Error("Invalid SingleModelEditStackElement");this._data instanceof Bt&&(this._data=this._data.serialize());const e=Bt.deserialize(this._data);this.model._applyRedo(e.changes,e.afterEOL,e.afterVersionId,e.afterCursorState)}heapSize(){return this._data instanceof Bt&&(this._data=this._data.serialize()),this._data.byteLength+168}}class Pt{get resources(){return this._editStackElementsArr.map((e=>e.resource))}constructor(e,t,n){this.label=e,this.code=t,this.type=1,this._isOpen=!0,this._editStackElementsArr=n.slice(0),this._editStackElementsMap=new Map;for(const r of this._editStackElementsArr){const e=Dt(r.resource);this._editStackElementsMap.set(e,r)}this._delegate=null}prepareUndoRedo(){if(this._delegate)return this._delegate.prepareUndoRedo(this)}matchesResource(e){const t=Dt(e);return this._editStackElementsMap.has(t)}setModel(e){const t=Dt(h.r.isUri(e)?e:e.uri);this._editStackElementsMap.has(t)&&this._editStackElementsMap.get(t).setModel(e)}canAppend(e){if(!this._isOpen)return!1;const t=Dt(e.uri);if(this._editStackElementsMap.has(t)){return this._editStackElementsMap.get(t).canAppend(e)}return!1}append(e,t,n,r,i){const s=Dt(e.uri);this._editStackElementsMap.get(s).append(e,t,n,r,i)}close(){this._isOpen=!1}open(){}undo(){this._isOpen=!1;for(const e of this._editStackElementsArr)e.undo()}redo(){for(const e of this._editStackElementsArr)e.redo()}heapSize(e){const t=Dt(e);if(this._editStackElementsMap.has(t)){return this._editStackElementsMap.get(t).heapSize()}return 0}split(){return this._editStackElementsArr}toString(){const e=[];for(const t of this._editStackElementsArr)e.push(`${(0,Rt.P8)(t.resource)}: ${t}`);return`{${e.join(", ")}}`}}function Vt(e){return"\n"===e.getEOL()?0:1}function zt(e){return!!e&&(e instanceof Ft||e instanceof Pt)}class jt{constructor(e,t){this._model=e,this._undoRedoService=t}pushStackElement(){const e=this._undoRedoService.getLastElement(this._model.uri);zt(e)&&e.close()}popStackElement(){const e=this._undoRedoService.getLastElement(this._model.uri);zt(e)&&e.open()}clear(){this._undoRedoService.removeElements(this._model.uri)}_getOrCreateEditStackElement(e,t){const n=this._undoRedoService.getLastElement(this._model.uri);if(zt(n)&&n.canAppend(this._model))return n;const r=new Ft(At.kg("edit","Typing"),"undoredo.textBufferEdit",this._model,e);return this._undoRedoService.pushElement(r,t),r}pushEOL(e){const t=this._getOrCreateEditStackElement(null,void 0);this._model.setEOL(e),t.append(this._model,[],Vt(this._model),this._model.getAlternativeVersionId(),null)}pushEditOperation(e,t,n,r){const i=this._getOrCreateEditStackElement(e,r),s=this._model.applyEdits(t,!0),o=jt._computeCursorState(n,s),a=s.map(((e,t)=>({index:t,textChange:e.textChange})));return a.sort(((e,t)=>e.textChange.oldPosition===t.textChange.oldPosition?e.index-t.index:e.textChange.oldPosition-t.textChange.oldPosition)),i.append(this._model,a.map((e=>e.textChange)),Vt(this._model),this._model.getAlternativeVersionId(),o),o}static _computeCursorState(e,t){try{return e?e(t):null}catch(n){return(0,l.dz)(n),null}}}var qt,Wt=n(6041);class Ut extends i.jG{constructor(){super(...arguments),this._isDisposed=!1}dispose(){super.dispose(),this._isDisposed=!0}assertNotDisposed(){if(this._isDisposed)throw new Error("TextModelPart is disposed!")}}!function(e){e[e.Disabled=0]="Disabled",e[e.EnabledForActive=1]="EnabledForActive",e[e.Enabled=2]="Enabled"}(qt||(qt={}));class $t{constructor(e,t,n,r,i,s){if(this.visibleColumn=e,this.column=t,this.className=n,this.horizontalLine=r,this.forWrappedLinesAfterColumn=i,this.forWrappedLinesBeforeOrAtColumn=s,-1!==e===(-1!==t))throw new Error}}class Ht{constructor(e,t){this.top=e,this.endColumn=t}}class Kt extends Ut{constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t}getLanguageConfiguration(e){return this.languageConfigurationService.getLanguageConfiguration(e)}_computeIndentLevel(e){return function(e,t){let n=0,r=0;const i=e.length;for(;rr)throw new l.D7("Illegal value for lineNumber");const i=this.getLanguageConfiguration(this.textModel.getLanguageId()).foldingRules,s=Boolean(i&&i.offSide);let o=-2,a=-1,c=-2,h=-1;const u=e=>{if(-1!==o&&(-2===o||o>e-1)){o=-1,a=-1;for(let t=e-2;t>=0;t--){const e=this._computeIndentLevel(t);if(e>=0){o=t,a=e;break}}}if(-2===c){c=-1,h=-1;for(let t=e;t=0){c=t,h=e;break}}}};let d=-2,g=-1,f=-2,m=-1;const p=e=>{if(-2===d){d=-1,g=-1;for(let t=e-2;t>=0;t--){const e=this._computeIndentLevel(t);if(e>=0){d=t,g=e;break}}}if(-1!==f&&(-2===f||f=0){f=t,m=e;break}}}};let b=0,_=!0,k=0,v=!0,C=0,y=0;for(let l=0;_||v;l++){const i=e-l,o=e+l;l>1&&(i<1||i1&&(o>r||o>n)&&(v=!1),l>5e4&&(_=!1,v=!1);let f=-1;if(_&&i>=1){const e=this._computeIndentLevel(i-1);e>=0?(c=i-1,h=e,f=Math.ceil(e/this.textModel.getOptions().indentSize)):(u(i),f=this._getIndentLevelForWhitespaceLine(s,a,h))}let L=-1;if(v&&o<=r){const e=this._computeIndentLevel(o-1);e>=0?(d=o-1,g=e,L=Math.ceil(e/this.textModel.getOptions().indentSize)):(p(o),L=this._getIndentLevelForWhitespaceLine(s,g,m))}if(0!==l){if(1===l){if(o<=r&&L>=0&&y+1===L){_=!1,b=o,k=o,C=L;continue}if(i>=1&&f>=0&&f-1===y){v=!1,b=i,k=i,C=f;continue}if(b=e,k=e,C=y,0===C)return{startLineNumber:b,endLineNumber:k,indent:C}}_&&(f>=C?b=i:_=!1),v&&(L>=C?k=o:v=!1)}else y=f}return{startLineNumber:b,endLineNumber:k,indent:C}}getLinesBracketGuides(e,t,n,r){const i=[];for(let c=e;c<=t;c++)i.push([]);const s=!0,o=this.textModel.bracketPairs.getBracketPairsInRangeWithMinIndentation(new m.Q(e,1,t,this.textModel.getLineMaxColumn(t))).toArray();let a;if(n&&o.length>0){const r=(e<=n.lineNumber&&n.lineNumber<=t?o:this.textModel.bracketPairs.getBracketPairsInRange(m.Q.fromPositions(n)).toArray()).filter((e=>m.Q.strictContainsPosition(e.range,n)));a=(0,Wt.Uk)(r,(e=>s))?.range}const l=this.textModel.getOptions().bracketPairColorizationOptions.independentColorPoolPerBracketType,h=new Gt;for(const u of o){if(!u.closingBracketRange)continue;const n=a&&u.range.equalsRange(a);if(!n&&!r.includeInactive)continue;const s=h.getInlineClassName(u.nestingLevel,u.nestingLevelOfEqualBracketType,l)+(r.highlightActive&&n?" "+h.activeClassName:""),o=u.openingBracketRange.getStartPosition(),d=u.closingBracketRange.getStartPosition(),g=r.horizontalGuides===qt.Enabled||r.horizontalGuides===qt.EnabledForActive&&n;if(u.range.startLineNumber===u.range.endLineNumber){g&&i[u.range.startLineNumber-e].push(new $t(-1,u.openingBracketRange.getEndPosition().column,s,new Ht(!1,d.column),-1,-1));continue}const f=this.getVisibleColumnFromPosition(d),m=this.getVisibleColumnFromPosition(u.openingBracketRange.getStartPosition()),p=Math.min(m,f,u.minVisibleColumnIndentation+1);let b=!1;c.HG(this.textModel.getLineContent(u.closingBracketRange.startLineNumber))=e&&m>p&&i[o.lineNumber-e].push(new $t(p,-1,s,new Ht(!1,o.column),-1,-1)),d.lineNumber<=t&&f>p&&i[d.lineNumber-e].push(new $t(p,-1,s,new Ht(!b,d.column),-1,-1)))}for(const c of i)c.sort(((e,t)=>e.visibleColumn-t.visibleColumn));return i}getVisibleColumnFromPosition(e){return d.visibleColumnFromColumn(this.textModel.getLineContent(e.lineNumber),e.column,this.textModel.getOptions().tabSize)+1}getLinesIndentGuides(e,t){this.assertNotDisposed();const n=this.textModel.getLineCount();if(e<1||e>n)throw new Error("Illegal value for startLineNumber");if(t<1||t>n)throw new Error("Illegal value for endLineNumber");const r=this.textModel.getOptions(),i=this.getLanguageConfiguration(this.textModel.getLanguageId()).foldingRules,s=Boolean(i&&i.offSide),o=new Array(t-e+1);let a=-2,l=-1,c=-2,h=-1;for(let u=e;u<=t;u++){const t=u-e,i=this._computeIndentLevel(u-1);if(i>=0)a=u-1,l=i,o[t]=Math.ceil(i/r.indentSize);else{if(-2===a){a=-1,l=-1;for(let e=u-2;e>=0;e--){const t=this._computeIndentLevel(e);if(t>=0){a=e,l=t;break}}}if(-1!==c&&(-2===c||c=0){c=e,h=t;break}}}o[t]=this._getIndentLevelForWhitespaceLine(s,l,h)}}return o}_getIndentLevelForWhitespaceLine(e,t,n){const r=this.textModel.getOptions();return-1===t||-1===n?0:t0&&a>0)return;if(l>0&&c>0)return;const h=Math.abs(a-c),u=Math.abs(o-l);if(0===h)return i.spacesDiff=u,void(u>0&&0<=l-1&&l-10?i++:m>1&&s++,Jt(o,a,l,f,h),h.looksLikeAlignment&&(!n||t!==h.spacesDiff))continue;const b=h.spacesDiff;b<=8&&c[b]++,o=l,a=f}let u=n;i!==s&&(u=i{const n=c[t];n>e&&(e=n,d=t)})),4===d&&c[4]>0&&c[2]>0&&c[2]>=c[4]/2&&(d=2)}return{insertSpaces:u,tabSize:d}}function Yt(e){return(1&e.metadata)>>>0}function Zt(e,t){e.metadata=254&e.metadata|t}function en(e){return(2&e.metadata)>>>1===1}function tn(e,t){e.metadata=253&e.metadata|(t?1:0)<<1}function nn(e){return(4&e.metadata)>>>2===1}function rn(e,t){e.metadata=251&e.metadata|(t?1:0)<<2}function sn(e){return(64&e.metadata)>>>6===1}function on(e,t){e.metadata=191&e.metadata|(t?1:0)<<6}function an(e,t){e.metadata=231&e.metadata|t<<3}function ln(e,t){e.metadata=223&e.metadata|(t?1:0)<<5}class cn{constructor(e,t,n){this.metadata=0,this.parent=this,this.left=this,this.right=this,Zt(this,1),this.start=t,this.end=n,this.delta=0,this.maxEnd=n,this.id=e,this.ownerId=0,this.options=null,rn(this,!1),on(this,!1),an(this,1),ln(this,!1),this.cachedVersionId=0,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=n,this.range=null,tn(this,!1)}reset(e,t,n,r){this.start=t,this.end=n,this.maxEnd=n,this.cachedVersionId=e,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=n,this.range=r}setOptions(e){this.options=e;const t=this.options.className;rn(this,"squiggly-error"===t||"squiggly-warning"===t||"squiggly-info"===t),on(this,null!==this.options.glyphMarginClassName),an(this,this.options.stickiness),ln(this,this.options.collapseOnReplaceEdit)}setCachedOffsets(e,t,n){this.cachedVersionId!==n&&(this.range=null),this.cachedVersionId=n,this.cachedAbsoluteStart=e,this.cachedAbsoluteEnd=t}detach(){this.parent=null,this.left=null,this.right=null}}const hn=new cn(null,0,0);hn.parent=hn,hn.left=hn,hn.right=hn,Zt(hn,0);class un{constructor(){this.root=hn,this.requestNormalizeDelta=!1}intervalSearch(e,t,n,r,i,s){return this.root===hn?[]:function(e,t,n,r,i,s,o){let a=e.root,l=0,c=0,h=0,u=0;const d=[];let g=0;for(;a!==hn;)if(en(a))tn(a.left,!1),tn(a.right,!1),a===a.parent.right&&(l-=a.parent.delta),a=a.parent;else{if(!en(a.left)){if(c=l+a.maxEnd,cn)tn(a,!0);else{if(u=l+a.end,u>=t){a.setCachedOffsets(h,u,s);let e=!0;r&&a.ownerId&&a.ownerId!==r&&(e=!1),i&&nn(a)&&(e=!1),o&&!sn(a)&&(e=!1),e&&(d[g++]=a)}tn(a,!0),a.right===hn||en(a.right)||(l+=a.delta,a=a.right)}}return tn(e.root,!1),d}(this,e,t,n,r,i,s)}search(e,t,n,r){return this.root===hn?[]:function(e,t,n,r,i){let s=e.root,o=0,a=0,l=0;const c=[];let h=0;for(;s!==hn;){if(en(s)){tn(s.left,!1),tn(s.right,!1),s===s.parent.right&&(o-=s.parent.delta),s=s.parent;continue}if(s.left!==hn&&!en(s.left)){s=s.left;continue}a=o+s.start,l=o+s.end,s.setCachedOffsets(a,l,r);let e=!0;t&&s.ownerId&&s.ownerId!==t&&(e=!1),n&&nn(s)&&(e=!1),i&&!sn(s)&&(e=!1),e&&(c[h++]=s),tn(s,!0),s.right===hn||en(s.right)||(o+=s.delta,s=s.right)}return tn(e.root,!1),c}(this,e,t,n,r)}collectNodesFromOwner(e){return function(e,t){let n=e.root;const r=[];let i=0;for(;n!==hn;)en(n)?(tn(n.left,!1),tn(n.right,!1),n=n.parent):n.left===hn||en(n.left)?(n.ownerId===t&&(r[i++]=n),tn(n,!0),n.right===hn||en(n.right)||(n=n.right)):n=n.left;return tn(e.root,!1),r}(this,e)}collectNodesPostOrder(){return function(e){let t=e.root;const n=[];let r=0;for(;t!==hn;)en(t)?(tn(t.left,!1),tn(t.right,!1),t=t.parent):t.left===hn||en(t.left)?t.right===hn||en(t.right)?(n[r++]=t,tn(t,!0)):t=t.right:t=t.left;return tn(e.root,!1),n}(this)}insert(e){fn(this,e),this._normalizeDeltaIfNecessary()}delete(e){mn(this,e),this._normalizeDeltaIfNecessary()}resolveNode(e,t){const n=e;let r=0;for(;e!==this.root;)e===e.parent.right&&(r+=e.parent.delta),e=e.parent;const i=n.start+r,s=n.end+r;n.setCachedOffsets(i,s,t)}acceptReplace(e,t,n,r){const i=function(e,t,n){let r=e.root,i=0,s=0,o=0,a=0;const l=[];let c=0;for(;r!==hn;)if(en(r))tn(r.left,!1),tn(r.right,!1),r===r.parent.right&&(i-=r.parent.delta),r=r.parent;else{if(!en(r.left)){if(s=i+r.maxEnd,sn?tn(r,!0):(a=i+r.end,a>=t&&(r.setCachedOffsets(o,a,0),l[c++]=r),tn(r,!0),r.right===hn||en(r.right)||(i+=r.delta,r=r.right))}return tn(e.root,!1),l}(this,e,e+t);for(let s=0,o=i.length;sn?(i.start+=l,i.end+=l,i.delta+=l,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),tn(i,!0)):(tn(i,!0),i.right===hn||en(i.right)||(s+=i.delta,i=i.right))}tn(e.root,!1)}(this,e,e+t,n),this._normalizeDeltaIfNecessary();for(let s=0,o=i.length;sn)&&(1!==r&&(2===r||t))}function gn(e,t,n,r,i){const s=function(e){return(24&e.metadata)>>>3}(e),o=0===s||2===s,a=1===s||2===s,l=n-t,c=r,h=Math.min(l,c),u=e.start;let d=!1;const g=e.end;let f=!1;t<=u&&g<=n&&function(e){return(32&e.metadata)>>>5===1}(e)&&(e.start=t,d=!0,e.end=t,f=!0);{const e=i?1:l>0?2:0;!d&&dn(u,o,t,e)&&(d=!0),!f&&dn(g,a,t,e)&&(f=!0)}if(h>0&&!i){const e=l>c?2:0;!d&&dn(u,o,t+h,e)&&(d=!0),!f&&dn(g,a,t+h,e)&&(f=!0)}{const r=i?1:0;!d&&dn(u,o,n,r)&&(e.start=t+c,d=!0),!f&&dn(g,a,n,r)&&(e.end=t+c,f=!0)}const m=c-l;d||(e.start=Math.max(0,u+m)),f||(e.end=Math.max(0,g+m)),e.start>e.end&&(e.end=e.start)}function fn(e,t){if(e.root===hn)return t.parent=hn,t.left=hn,t.right=hn,Zt(t,0),e.root=t,e.root;!function(e,t){let n=0,r=e.root;const i=t.start,s=t.end;for(;;){if(yn(i,s,r.start+n,r.end+n)<0){if(r.left===hn){t.start-=n,t.end-=n,t.maxEnd-=n,r.left=t;break}r=r.left}else{if(r.right===hn){t.start-=n+r.delta,t.end-=n+r.delta,t.maxEnd-=n+r.delta,r.right=t;break}n+=r.delta,r=r.right}}t.parent=r,t.left=hn,t.right=hn,Zt(t,1)}(e,t),Cn(t.parent);let n=t;for(;n!==e.root&&1===Yt(n.parent);)if(n.parent===n.parent.parent.left){const t=n.parent.parent.right;1===Yt(t)?(Zt(n.parent,0),Zt(t,0),Zt(n.parent.parent,1),n=n.parent.parent):(n===n.parent.right&&(n=n.parent,bn(e,n)),Zt(n.parent,0),Zt(n.parent.parent,1),_n(e,n.parent.parent))}else{const t=n.parent.parent.left;1===Yt(t)?(Zt(n.parent,0),Zt(t,0),Zt(n.parent.parent,1),n=n.parent.parent):(n===n.parent.left&&(n=n.parent,_n(e,n)),Zt(n.parent,0),Zt(n.parent.parent,1),bn(e,n.parent.parent))}return Zt(e.root,0),t}function mn(e,t){let n,r;if(t.left===hn?(n=t.right,r=t,n.delta+=t.delta,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),n.start+=t.delta,n.end+=t.delta):t.right===hn?(n=t.left,r=t):(r=function(e){for(;e.left!==hn;)e=e.left;return e}(t.right),n=r.right,n.start+=r.delta,n.end+=r.delta,n.delta+=r.delta,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),r.start+=t.delta,r.end+=t.delta,r.delta=t.delta,(r.delta<-1073741824||r.delta>1073741824)&&(e.requestNormalizeDelta=!0)),r===e.root)return e.root=n,Zt(n,0),t.detach(),pn(),vn(n),void(e.root.parent=hn);const i=1===Yt(r);if(r===r.parent.left?r.parent.left=n:r.parent.right=n,r===t?n.parent=r.parent:(r.parent===t?n.parent=r:n.parent=r.parent,r.left=t.left,r.right=t.right,r.parent=t.parent,Zt(r,Yt(t)),t===e.root?e.root=r:t===t.parent.left?t.parent.left=r:t.parent.right=r,r.left!==hn&&(r.left.parent=r),r.right!==hn&&(r.right.parent=r)),t.detach(),i)return Cn(n.parent),r!==t&&(Cn(r),Cn(r.parent)),void pn();let s;for(Cn(n),Cn(n.parent),r!==t&&(Cn(r),Cn(r.parent));n!==e.root&&0===Yt(n);)n===n.parent.left?(s=n.parent.right,1===Yt(s)&&(Zt(s,0),Zt(n.parent,1),bn(e,n.parent),s=n.parent.right),0===Yt(s.left)&&0===Yt(s.right)?(Zt(s,1),n=n.parent):(0===Yt(s.right)&&(Zt(s.left,0),Zt(s,1),_n(e,s),s=n.parent.right),Zt(s,Yt(n.parent)),Zt(n.parent,0),Zt(s.right,0),bn(e,n.parent),n=e.root)):(s=n.parent.left,1===Yt(s)&&(Zt(s,0),Zt(n.parent,1),_n(e,n.parent),s=n.parent.left),0===Yt(s.left)&&0===Yt(s.right)?(Zt(s,1),n=n.parent):(0===Yt(s.left)&&(Zt(s.right,0),Zt(s,1),bn(e,s),s=n.parent.left),Zt(s,Yt(n.parent)),Zt(n.parent,0),Zt(s.left,0),_n(e,n.parent),n=e.root));Zt(n,0),pn()}function pn(){hn.parent=hn,hn.delta=0,hn.start=0,hn.end=0}function bn(e,t){const n=t.right;n.delta+=t.delta,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),n.start+=t.delta,n.end+=t.delta,t.right=n.left,n.left!==hn&&(n.left.parent=t),n.parent=t.parent,t.parent===hn?e.root=n:t===t.parent.left?t.parent.left=n:t.parent.right=n,n.left=t,t.parent=n,vn(t),vn(n)}function _n(e,t){const n=t.left;t.delta-=n.delta,(t.delta<-1073741824||t.delta>1073741824)&&(e.requestNormalizeDelta=!0),t.start-=n.delta,t.end-=n.delta,t.left=n.right,n.right!==hn&&(n.right.parent=t),n.parent=t.parent,t.parent===hn?e.root=n:t===t.parent.right?t.parent.right=n:t.parent.left=n,n.right=t,t.parent=n,vn(t),vn(n)}function kn(e){let t=e.end;if(e.left!==hn){const n=e.left.maxEnd;n>t&&(t=n)}if(e.right!==hn){const n=e.right.maxEnd+e.delta;n>t&&(t=n)}return t}function vn(e){e.maxEnd=kn(e)}function Cn(e){for(;e!==hn;){const t=kn(e);if(e.maxEnd===t)return;e.maxEnd=t,e=e.parent}}function yn(e,t,n,r){return e===n?t-r:e-n}class Ln{constructor(e,t){this.piece=e,this.color=t,this.size_left=0,this.lf_left=0,this.parent=this,this.left=this,this.right=this}next(){if(this.right!==wn)return Sn(this.right);let e=this;for(;e.parent!==wn&&e.parent.left!==e;)e=e.parent;return e.parent===wn?wn:e.parent}prev(){if(this.left!==wn)return xn(this.left);let e=this;for(;e.parent!==wn&&e.parent.right!==e;)e=e.parent;return e.parent===wn?wn:e.parent}detach(){this.parent=null,this.left=null,this.right=null}}const wn=new Ln(null,0);function Sn(e){for(;e.left!==wn;)e=e.left;return e}function xn(e){for(;e.right!==wn;)e=e.right;return e}function En(e){return e===wn?0:e.size_left+e.piece.length+En(e.right)}function Nn(e){return e===wn?0:e.lf_left+e.piece.lineFeedCnt+Nn(e.right)}function Tn(){wn.parent=wn}function An(e,t){const n=t.right;n.size_left+=t.size_left+(t.piece?t.piece.length:0),n.lf_left+=t.lf_left+(t.piece?t.piece.lineFeedCnt:0),t.right=n.left,n.left!==wn&&(n.left.parent=t),n.parent=t.parent,t.parent===wn?e.root=n:t.parent.left===t?t.parent.left=n:t.parent.right=n,n.left=t,t.parent=n}function In(e,t){const n=t.left;t.left=n.right,n.right!==wn&&(n.right.parent=t),n.parent=t.parent,t.size_left-=n.size_left+(n.piece?n.piece.length:0),t.lf_left-=n.lf_left+(n.piece?n.piece.lineFeedCnt:0),t.parent===wn?e.root=n:t===t.parent.right?t.parent.right=n:t.parent.left=n,n.right=t,t.parent=n}function On(e,t){let n,r;if(t.left===wn?(r=t,n=r.right):t.right===wn?(r=t,n=r.left):(r=Sn(t.right),n=r.right),r===e.root)return e.root=n,n.color=0,t.detach(),Tn(),void(e.root.parent=wn);const i=1===r.color;if(r===r.parent.left?r.parent.left=n:r.parent.right=n,r===t?(n.parent=r.parent,Dn(e,n)):(r.parent===t?n.parent=r:n.parent=r.parent,Dn(e,n),r.left=t.left,r.right=t.right,r.parent=t.parent,r.color=t.color,t===e.root?e.root=r:t===t.parent.left?t.parent.left=r:t.parent.right=r,r.left!==wn&&(r.left.parent=r),r.right!==wn&&(r.right.parent=r),r.size_left=t.size_left,r.lf_left=t.lf_left,Dn(e,r)),t.detach(),n.parent.left===n){const t=En(n),r=Nn(n);if(t!==n.parent.size_left||r!==n.parent.lf_left){const i=t-n.parent.size_left,s=r-n.parent.lf_left;n.parent.size_left=t,n.parent.lf_left=r,Rn(e,n.parent,i,s)}}if(Dn(e,n.parent),i)return void Tn();let s;for(;n!==e.root&&0===n.color;)n===n.parent.left?(s=n.parent.right,1===s.color&&(s.color=0,n.parent.color=1,An(e,n.parent),s=n.parent.right),0===s.left.color&&0===s.right.color?(s.color=1,n=n.parent):(0===s.right.color&&(s.left.color=0,s.color=1,In(e,s),s=n.parent.right),s.color=n.parent.color,n.parent.color=0,s.right.color=0,An(e,n.parent),n=e.root)):(s=n.parent.left,1===s.color&&(s.color=0,n.parent.color=1,In(e,n.parent),s=n.parent.left),0===s.left.color&&0===s.right.color?(s.color=1,n=n.parent):(0===s.left.color&&(s.right.color=0,s.color=1,An(e,s),s=n.parent.left),s.color=n.parent.color,n.parent.color=0,s.left.color=0,In(e,n.parent),n=e.root));n.color=0,Tn()}function Mn(e,t){for(Dn(e,t);t!==e.root&&1===t.parent.color;)if(t.parent===t.parent.parent.left){const n=t.parent.parent.right;1===n.color?(t.parent.color=0,n.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.right&&An(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,In(e,t.parent.parent))}else{const n=t.parent.parent.left;1===n.color?(t.parent.color=0,n.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.left&&In(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,An(e,t.parent.parent))}e.root.color=0}function Rn(e,t,n,r){for(;t!==e.root&&t!==wn;)t.parent.left===t&&(t.parent.size_left+=n,t.parent.lf_left+=r),t=t.parent}function Dn(e,t){let n=0,r=0;if(t!==e.root){for(;t!==e.root&&t===t.parent.right;)t=t.parent;if(t!==e.root)for(n=En((t=t.parent).left)-t.size_left,r=Nn(t.left)-t.lf_left,t.size_left+=n,t.lf_left+=r;t!==e.root&&(0!==n||0!==r);)t.parent.left===t&&(t.parent.size_left+=n,t.parent.lf_left+=r),t=t.parent}}wn.parent=wn,wn.left=wn,wn.right=wn,wn.color=0;var Bn=n(7729);const Fn=65535;function Pn(e){let t;return t=e[e.length-1]<65536?new Uint16Array(e.length):new Uint32Array(e.length),t.set(e,0),t}class Vn{constructor(e,t,n,r,i){this.lineStarts=e,this.cr=t,this.lf=n,this.crlf=r,this.isBasicASCII=i}}function zn(e,t=!0){const n=[0];let r=1;for(let i=0,s=e.length;i(e!==wn&&this._pieces.push(e.piece),!0)))}read(){return 0===this._pieces.length?0===this._index?(this._index++,this._BOM):null:this._index>this._pieces.length-1?null:0===this._index?this._BOM+this._tree.getPieceContent(this._pieces[this._index++]):this._tree.getPieceContent(this._pieces[this._index++])}}class Un{constructor(e){this._limit=e,this._cache=[]}get(e){for(let t=this._cache.length-1;t>=0;t--){const n=this._cache[t];if(n.nodeStartOffset<=e&&n.nodeStartOffset+n.node.piece.length>=e)return n}return null}get2(e){for(let t=this._cache.length-1;t>=0;t--){const n=this._cache[t];if(n.nodeStartLineNumber&&n.nodeStartLineNumber=e)return n}return null}set(e){this._cache.length>=this._limit&&this._cache.shift(),this._cache.push(e)}validate(e){let t=!1;const n=this._cache;for(let r=0;r=e)&&(n[r]=null,t=!0)}if(t){const e=[];for(const t of n)null!==t&&e.push(t);this._cache=e}}}class $n{constructor(e,t,n){this.create(e,t,n)}create(e,t,n){this._buffers=[new qn("",[0])],this._lastChangeBufferPos={line:0,column:0},this.root=wn,this._lineCnt=1,this._length=0,this._EOL=t,this._EOLLength=t.length,this._EOLNormalized=n;let r=null;for(let i=0,s=e.length;i0){e[i].lineStarts||(e[i].lineStarts=zn(e[i].buffer));const t=new jn(i+1,{line:0,column:0},{line:e[i].lineStarts.length-1,column:e[i].buffer.length-e[i].lineStarts[e[i].lineStarts.length-1]},e[i].lineStarts.length-1,e[i].buffer.length);this._buffers.push(e[i]),r=this.rbInsertRight(r,t)}this._searchCache=new Un(1),this._lastVisitedLine={lineNumber:0,value:""},this.computeBufferMetadata()}normalizeEOL(e){const t=Fn,n=t-Math.floor(21845),r=2*n;let i="",s=0;const o=[];if(this.iterate(this.root,(t=>{const a=this.getNodeContent(t),l=a.length;if(s<=n||s+l0){const t=i.replace(/\r\n|\r|\n/g,e);o.push(new qn(t,zn(t)))}this.create(o,e,!0)}getEOL(){return this._EOL}setEOL(e){this._EOL=e,this._EOLLength=this._EOL.length,this.normalizeEOL(e)}createSnapshot(e){return new Wn(this,e)}getOffsetAt(e,t){let n=0,r=this.root;for(;r!==wn;)if(r.left!==wn&&r.lf_left+1>=e)r=r.left;else{if(r.lf_left+r.piece.lineFeedCnt+1>=e){n+=r.size_left;return n+(this.getAccumulatedValue(r,e-r.lf_left-2)+t-1)}e-=r.lf_left+r.piece.lineFeedCnt,n+=r.size_left+r.piece.length,r=r.right}return n}getPositionAt(e){e=Math.floor(e),e=Math.max(0,e);let t=this.root,n=0;const r=e;for(;t!==wn;)if(0!==t.size_left&&t.size_left>=e)t=t.left;else{if(t.size_left+t.piece.length>=e){const i=this.getIndexOf(t,e-t.size_left);if(n+=t.lf_left+i.index,0===i.index){const e=r-this.getOffsetAt(n+1,1);return new f.y(n+1,e+1)}return new f.y(n+1,i.remainder+1)}if(e-=t.size_left+t.piece.length,n+=t.lf_left+t.piece.lineFeedCnt,t.right===wn){const t=r-e-this.getOffsetAt(n+1,1);return new f.y(n+1,t+1)}t=t.right}return new f.y(1,1)}getValueInRange(e,t){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return"";const n=this.nodeAt2(e.startLineNumber,e.startColumn),r=this.nodeAt2(e.endLineNumber,e.endColumn),i=this.getValueInRange2(n,r);return t?t===this._EOL&&this._EOLNormalized&&t===this.getEOL()&&this._EOLNormalized?i:i.replace(/\r\n|\r|\n/g,t):i}getValueInRange2(e,t){if(e.node===t.node){const n=e.node,r=this._buffers[n.piece.bufferIndex].buffer,i=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);return r.substring(i+e.remainder,i+t.remainder)}let n=e.node;const r=this._buffers[n.piece.bufferIndex].buffer,i=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);let s=r.substring(i+e.remainder,i+n.piece.length);for(n=n.next();n!==wn;){const e=this._buffers[n.piece.bufferIndex].buffer,r=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);if(n===t.node){s+=e.substring(r,r+t.remainder);break}s+=e.substr(r,n.piece.length),n=n.next()}return s}getLinesContent(){const e=[];let t=0,n="",r=!1;return this.iterate(this.root,(i=>{if(i===wn)return!0;const s=i.piece;let o=s.length;if(0===o)return!0;const a=this._buffers[s.bufferIndex].buffer,l=this._buffers[s.bufferIndex].lineStarts,c=s.start.line,h=s.end.line;let u=l[c]+s.start.column;if(r&&(10===a.charCodeAt(u)&&(u++,o--),e[t++]=n,n="",r=!1,0===o))return!0;if(c===h)return this._EOLNormalized||13!==a.charCodeAt(u+o-1)?n+=a.substr(u,o):(r=!0,n+=a.substr(u,o-1)),!0;n+=this._EOLNormalized?a.substring(u,Math.max(u,l[c+1]-this._EOLLength)):a.substring(u,l[c+1]).replace(/(\r\n|\r|\n)$/,""),e[t++]=n;for(let r=c+1;re+g,t.reset(0)):(_=u.buffer,k=e=>e,t.reset(g));do{if(p=t.next(_),p){if(k(p.index)>=f)return c;this.positionInBuffer(e,k(p.index)-d,b);const t=this.getLineFeedCnt(e.piece.bufferIndex,i,b),s=b.line===i.line?b.column-i.column+r:b.column+1,o=s+p[0].length;if(h[c++]=(0,Bn.dr)(new m.Q(n+t,s,n+t,o),p,a),k(p.index)+p[0].length>=f)return c;if(c>=l)return c}}while(p);return c}findMatchesLineByLine(e,t,n,r){const i=[];let s=0;const o=new Bn.W5(t.wordSeparators,t.regex);let a=this.nodeAt2(e.startLineNumber,e.startColumn);if(null===a)return[];const l=this.nodeAt2(e.endLineNumber,e.endColumn);if(null===l)return[];let c=this.positionInBuffer(a.node,a.remainder);const h=this.positionInBuffer(l.node,l.remainder);if(a.node===l.node)return this.findMatchesInNode(a.node,o,e.startLineNumber,e.startColumn,c,h,t,n,r,s,i),i;let u=e.startLineNumber,d=a.node;for(;d!==l.node;){const l=this.getLineFeedCnt(d.piece.bufferIndex,c,d.piece.end);if(l>=1){const a=this._buffers[d.piece.bufferIndex].lineStarts,h=this.offsetInBuffer(d.piece.bufferIndex,d.piece.start),g=a[c.line+l],f=u===e.startLineNumber?e.startColumn:1;if(s=this.findMatchesInNode(d,o,u,f,c,this.positionInBuffer(d,g-h),t,n,r,s,i),s>=r)return i;u+=l}const h=u===e.startLineNumber?e.startColumn-1:0;if(u===e.endLineNumber){const a=this.getLineContent(u).substring(h,e.endColumn-1);return s=this._findMatchesInLine(t,o,a,e.endLineNumber,h,s,i,n,r),i}if(s=this._findMatchesInLine(t,o,this.getLineContent(u).substr(h),u,h,s,i,n,r),s>=r)return i;u++,a=this.nodeAt2(u,1),d=a.node,c=this.positionInBuffer(a.node,a.remainder)}if(u===e.endLineNumber){const a=u===e.startLineNumber?e.startColumn-1:0,l=this.getLineContent(u).substring(a,e.endColumn-1);return s=this._findMatchesInLine(t,o,l,e.endLineNumber,a,s,i,n,r),i}const g=u===e.startLineNumber?e.startColumn:1;return s=this.findMatchesInNode(l.node,o,u,g,c,h,t,n,r,s,i),i}_findMatchesInLine(e,t,n,r,i,s,o,a,l){const c=e.wordSeparators;if(!a&&e.simpleSearch){const t=e.simpleSearch,a=t.length,h=n.length;let u=-a;for(;-1!==(u=n.indexOf(t,u+a));)if((!c||(0,Bn.wC)(c,n,h,u,a))&&(o[s++]=new me.Dg(new m.Q(r,u+1+i,r,u+1+a+i),null),s>=l))return s;return s}let h;t.reset(0);do{if(h=t.next(n),h&&(o[s++]=(0,Bn.dr)(new m.Q(r,h.index+1+i,r,h.index+1+h[0].length+i),h,a),s>=l))return s}while(h);return s}insert(e,t,n=!1){if(this._EOLNormalized=this._EOLNormalized&&n,this._lastVisitedLine.lineNumber=0,this._lastVisitedLine.value="",this.root!==wn){const{node:n,remainder:r,nodeStartOffset:i}=this.nodeAt(e),s=n.piece,o=s.bufferIndex,a=this.positionInBuffer(n,r);if(0===n.piece.bufferIndex&&s.end.line===this._lastChangeBufferPos.line&&s.end.column===this._lastChangeBufferPos.column&&i+s.length===e&&t.lengthe){const e=[];let i=new jn(s.bufferIndex,a,s.end,this.getLineFeedCnt(s.bufferIndex,a,s.end),this.offsetInBuffer(o,s.end)-this.offsetInBuffer(o,a));if(this.shouldCheckCRLF()&&this.endWithCR(t)){if(10===this.nodeCharCodeAt(n,r)){const e={line:i.start.line+1,column:0};i=new jn(i.bufferIndex,e,i.end,this.getLineFeedCnt(i.bufferIndex,e,i.end),i.length-1),t+="\n"}}if(this.shouldCheckCRLF()&&this.startWithLF(t)){if(13===this.nodeCharCodeAt(n,r-1)){const i=this.positionInBuffer(n,r-1);this.deleteNodeTail(n,i),t="\r"+t,0===n.piece.length&&e.push(n)}else this.deleteNodeTail(n,a)}else this.deleteNodeTail(n,a);const l=this.createNewPieces(t);i.length>0&&this.rbInsertRight(n,i);let c=n;for(let t=0;t=0;s--)i=this.rbInsertLeft(i,r[s]);this.validateCRLFWithPrevNode(i),this.deleteNodes(n)}insertContentToNodeRight(e,t){this.adjustCarriageReturnFromNext(e,t)&&(e+="\n");const n=this.createNewPieces(e),r=this.rbInsertRight(t,n[0]);let i=r;for(let s=1;s=h))break;a=c+1}return n?(n.line=c,n.column=o-u,null):{line:c,column:o-u}}getLineFeedCnt(e,t,n){if(0===n.column)return n.line-t.line;const r=this._buffers[e].lineStarts;if(n.line===r.length-1)return n.line-t.line;const i=r[n.line+1],s=r[n.line]+n.column;if(i>s+1)return n.line-t.line;const o=s-1;return 13===this._buffers[e].buffer.charCodeAt(o)?n.line-t.line+1:n.line-t.line}offsetInBuffer(e,t){return this._buffers[e].lineStarts[t.line]+t.column}deleteNodes(e){for(let t=0;tFn){const t=[];for(;e.length>Fn;){const n=e.charCodeAt(65534);let r;13===n||n>=55296&&n<=56319?(r=e.substring(0,65534),e=e.substring(65534)):(r=e.substring(0,Fn),e=e.substring(Fn));const i=zn(r);t.push(new jn(this._buffers.length,{line:0,column:0},{line:i.length-1,column:r.length-i[i.length-1]},i.length-1,r.length)),this._buffers.push(new qn(r,i))}const n=zn(e);return t.push(new jn(this._buffers.length,{line:0,column:0},{line:n.length-1,column:e.length-n[n.length-1]},n.length-1,e.length)),this._buffers.push(new qn(e,n)),t}let t=this._buffers[0].buffer.length;const n=zn(e,!1);let r=this._lastChangeBufferPos;if(this._buffers[0].lineStarts[this._buffers[0].lineStarts.length-1]===t&&0!==t&&this.startWithLF(e)&&this.endWithCR(this._buffers[0].buffer)){this._lastChangeBufferPos={line:this._lastChangeBufferPos.line,column:this._lastChangeBufferPos.column+1},r=this._lastChangeBufferPos;for(let e=0;e=e-1)n=n.left;else{if(n.lf_left+n.piece.lineFeedCnt>e-1){const r=this.getAccumulatedValue(n,e-n.lf_left-2),o=this.getAccumulatedValue(n,e-n.lf_left-1),a=this._buffers[n.piece.bufferIndex].buffer,l=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);return i+=n.size_left,this._searchCache.set({node:n,nodeStartOffset:i,nodeStartLineNumber:s-(e-1-n.lf_left)}),a.substring(l+r,l+o-t)}if(n.lf_left+n.piece.lineFeedCnt===e-1){const t=this.getAccumulatedValue(n,e-n.lf_left-2),i=this._buffers[n.piece.bufferIndex].buffer,s=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);r=i.substring(s+t,s+n.piece.length);break}e-=n.lf_left+n.piece.lineFeedCnt,i+=n.size_left+n.piece.length,n=n.right}}for(n=n.next();n!==wn;){const e=this._buffers[n.piece.bufferIndex].buffer;if(n.piece.lineFeedCnt>0){const i=this.getAccumulatedValue(n,0),s=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);return r+=e.substring(s,s+i-t),r}{const t=this.offsetInBuffer(n.piece.bufferIndex,n.piece.start);r+=e.substr(t,n.piece.length)}n=n.next()}return r}computeBufferMetadata(){let e=this.root,t=1,n=0;for(;e!==wn;)t+=e.lf_left+e.piece.lineFeedCnt,n+=e.size_left+e.piece.length,e=e.right;this._lineCnt=t,this._length=n,this._searchCache.validate(this._length)}getIndexOf(e,t){const n=e.piece,r=this.positionInBuffer(e,t),i=r.line-n.start.line;if(this.offsetInBuffer(n.bufferIndex,n.end)-this.offsetInBuffer(n.bufferIndex,n.start)===t){const t=this.getLineFeedCnt(e.piece.bufferIndex,n.start,r);if(t!==i)return{index:t,remainder:0}}return{index:i,remainder:r.column}}getAccumulatedValue(e,t){if(t<0)return 0;const n=e.piece,r=this._buffers[n.bufferIndex].lineStarts,i=n.start.line+t+1;return i>n.end.line?r[n.end.line]+n.end.column-r[n.start.line]-n.start.column:r[i]-r[n.start.line]-n.start.column}deleteNodeTail(e,t){const n=e.piece,r=n.lineFeedCnt,i=this.offsetInBuffer(n.bufferIndex,n.end),s=t,o=this.offsetInBuffer(n.bufferIndex,s),a=this.getLineFeedCnt(n.bufferIndex,n.start,s),l=a-r,c=o-i,h=n.length+c;e.piece=new jn(n.bufferIndex,n.start,s,a,h),Rn(this,e,c,l)}deleteNodeHead(e,t){const n=e.piece,r=n.lineFeedCnt,i=this.offsetInBuffer(n.bufferIndex,n.start),s=t,o=this.getLineFeedCnt(n.bufferIndex,s,n.end),a=o-r,l=i-this.offsetInBuffer(n.bufferIndex,s),c=n.length+l;e.piece=new jn(n.bufferIndex,s,n.end,o,c),Rn(this,e,l,a)}shrinkNode(e,t,n){const r=e.piece,i=r.start,s=r.end,o=r.length,a=r.lineFeedCnt,l=t,c=this.getLineFeedCnt(r.bufferIndex,r.start,l),h=this.offsetInBuffer(r.bufferIndex,t)-this.offsetInBuffer(r.bufferIndex,i);e.piece=new jn(r.bufferIndex,r.start,l,c,h),Rn(this,e,h-o,c-a);const u=new jn(r.bufferIndex,n,s,this.getLineFeedCnt(r.bufferIndex,n,s),this.offsetInBuffer(r.bufferIndex,s)-this.offsetInBuffer(r.bufferIndex,n)),d=this.rbInsertRight(e,u);this.validateCRLFWithPrevNode(d)}appendToNode(e,t){this.adjustCarriageReturnFromNext(t,e)&&(t+="\n");const n=this.shouldCheckCRLF()&&this.startWithLF(t)&&this.endWithCR(e),r=this._buffers[0].buffer.length;this._buffers[0].buffer+=t;const i=zn(t,!1);for(let u=0;ue)t=t.left;else{if(t.size_left+t.piece.length>=e){r+=t.size_left;const n={node:t,remainder:e-t.size_left,nodeStartOffset:r};return this._searchCache.set(n),n}e-=t.size_left+t.piece.length,r+=t.size_left+t.piece.length,t=t.right}return null}nodeAt2(e,t){let n=this.root,r=0;for(;n!==wn;)if(n.left!==wn&&n.lf_left>=e-1)n=n.left;else{if(n.lf_left+n.piece.lineFeedCnt>e-1){const i=this.getAccumulatedValue(n,e-n.lf_left-2),s=this.getAccumulatedValue(n,e-n.lf_left-1);return r+=n.size_left,{node:n,remainder:Math.min(i+t-1,s),nodeStartOffset:r}}if(n.lf_left+n.piece.lineFeedCnt===e-1){const i=this.getAccumulatedValue(n,e-n.lf_left-2);if(i+t-1<=n.piece.length)return{node:n,remainder:i+t-1,nodeStartOffset:r};t-=n.piece.length-i;break}e-=n.lf_left+n.piece.lineFeedCnt,r+=n.size_left+n.piece.length,n=n.right}for(n=n.next();n!==wn;){if(n.piece.lineFeedCnt>0){const e=this.getAccumulatedValue(n,0),r=this.offsetOfNode(n);return{node:n,remainder:Math.min(t-1,e),nodeStartOffset:r}}if(n.piece.length>=t-1){return{node:n,remainder:t-1,nodeStartOffset:this.offsetOfNode(n)}}t-=n.piece.length,n=n.next()}return null}nodeCharCodeAt(e,t){if(e.piece.lineFeedCnt<1)return-1;const n=this._buffers[e.piece.bufferIndex],r=this.offsetInBuffer(e.piece.bufferIndex,e.piece.start)+t;return n.buffer.charCodeAt(r)}offsetOfNode(e){if(!e)return 0;let t=e.size_left;for(;e!==this.root;)e.parent.right===e&&(t+=e.parent.size_left+e.parent.piece.length),e=e.parent;return t}shouldCheckCRLF(){return!(this._EOLNormalized&&"\n"===this._EOL)}startWithLF(e){if("string"===typeof e)return 10===e.charCodeAt(0);if(e===wn||0===e.piece.lineFeedCnt)return!1;const t=e.piece,n=this._buffers[t.bufferIndex].lineStarts,r=t.start.line,i=n[r]+t.start.column;if(r===n.length-1)return!1;return!(n[r+1]>i+1)&&10===this._buffers[t.bufferIndex].buffer.charCodeAt(i)}endWithCR(e){return"string"===typeof e?13===e.charCodeAt(e.length-1):e!==wn&&0!==e.piece.lineFeedCnt&&13===this.nodeCharCodeAt(e,e.piece.length-1)}validateCRLFWithPrevNode(e){if(this.shouldCheckCRLF()&&this.startWithLF(e)){const t=e.prev();this.endWithCR(t)&&this.fixCRLF(t,e)}}validateCRLFWithNextNode(e){if(this.shouldCheckCRLF()&&this.endWithCR(e)){const t=e.next();this.startWithLF(t)&&this.fixCRLF(e,t)}}fixCRLF(e,t){const n=[],r=this._buffers[e.piece.bufferIndex].lineStarts;let i;i=0===e.piece.end.column?{line:e.piece.end.line-1,column:r[e.piece.end.line]-r[e.piece.end.line-1]-1}:{line:e.piece.end.line,column:e.piece.end.column-1};const s=e.piece.length-1,o=e.piece.lineFeedCnt-1;e.piece=new jn(e.piece.bufferIndex,e.piece.start,i,o,s),Rn(this,e,-1,-1),0===e.piece.length&&n.push(e);const a={line:t.piece.start.line+1,column:0},l=t.piece.length-1,c=this.getLineFeedCnt(t.piece.bufferIndex,a,t.piece.end);t.piece=new jn(t.piece.bufferIndex,a,t.piece.end,c,l),Rn(this,t,-1,-1),0===t.piece.length&&n.push(t);const h=this.createNewPieces("\r\n");this.rbInsertRight(e,h[0]);for(let u=0;ue.sortIndex-t.sortIndex))}this._mightContainRTL=r,this._mightContainUnusualLineTerminators=i,this._mightContainNonBasicASCII=s;const f=this._doApplyEdits(a);let m=null;if(t&&d.length>0){d.sort(((e,t)=>t.lineNumber-e.lineNumber)),m=[];for(let e=0,t=d.length;e0&&d[e-1].lineNumber===t)continue;const n=d[e].oldContent,r=this.getLineContent(t);0!==r.length&&r!==n&&-1===c.HG(r)&&m.push(t)}}return this._onDidChangeContent.fire(),new me.F4(g,f,m)}_reduceOperations(e){return e.length<1e3?e:[this._toSingleEditOperation(e)]}_toSingleEditOperation(e){let t=!1;const n=e[0].range,r=e[e.length-1].range,i=new m.Q(n.startLineNumber,n.startColumn,r.endLineNumber,r.endColumn);let s=n.startLineNumber,o=n.startColumn;const a=[];for(let u=0,g=e.length;u0&&a.push(n.text),s=r.endLineNumber,o=r.endColumn}const l=a.join(""),[c,h,d]=(0,u.W)(l);return{sortIndex:0,identifier:e[0].identifier,range:i,rangeOffset:this.getOffsetAt(i.startLineNumber,i.startColumn),rangeLength:this.getValueLengthInRange(i,0),text:l,eolCount:c,firstLineLength:h,lastLineLength:d,forceMoveMarkers:t,isAutoWhitespaceEdit:!1}}_doApplyEdits(e){e.sort(Hn._sortOpsDescending);const t=[];for(let n=0;n0){const e=o.eolCount+1;c=1===e?new m.Q(a,l,a,l+o.firstLineLength):new m.Q(a,l,a+e-1,o.lastLineLength+1)}else c=new m.Q(a,l,a,l);n=c.endLineNumber,r=c.endColumn,t.push(c),i=o}return t}static _sortOpsAscending(e,t){const n=m.Q.compareRangesUsingEnds(e.range,t.range);return 0===n?e.sortIndex-t.sortIndex:n}static _sortOpsDescending(e,t){const n=m.Q.compareRangesUsingEnds(e.range,t.range);return 0===n?t.sortIndex-e.sortIndex:-n}}class Kn{constructor(e,t,n,r,i,s,o,a,l){this._chunks=e,this._bom=t,this._cr=n,this._lf=r,this._crlf=i,this._containsRTL=s,this._containsUnusualLineTerminators=o,this._isBasicASCII=a,this._normalizeEOL=l}_getEOL(e){const t=this._cr+this._lf+this._crlf,n=this._cr+this._crlf;return 0===t?1===e?"\n":"\r\n":n>t/2?"\r\n":"\n"}create(e){const t=this._getEOL(e),n=this._chunks;if(this._normalizeEOL&&("\r\n"===t&&(this._cr>0||this._lf>0)||"\n"===t&&(this._cr>0||this._crlf>0)))for(let i=0,s=n.length;i=55296&&t<=56319?(this._acceptChunk1(e.substr(0,e.length-1),!1),this._hasPreviousChar=!0,this._previousChar=t):(this._acceptChunk1(e,!1),this._hasPreviousChar=!1,this._previousChar=t)}_acceptChunk1(e,t){(t||0!==e.length)&&(this._hasPreviousChar?this._acceptChunk2(String.fromCharCode(this._previousChar)+e):this._acceptChunk2(e))}_acceptChunk2(e){const t=function(e,t){e.length=0,e[0]=0;let n=1,r=0,i=0,s=0,o=!0;for(let l=0,c=t.length;l126)&&(o=!1)}const a=new Vn(Pn(e),r,i,s,o);return e.length=0,a}(this._tmpLineStarts,e);this.chunks.push(new qn(e,t.lineStarts)),this.cr+=t.cr,this.lf+=t.lf,this.crlf+=t.crlf,t.isBasicASCII||(this.isBasicASCII=!1,this.containsRTL||(this.containsRTL=c.E_(e)),this.containsUnusualLineTerminators||(this.containsUnusualLineTerminators=c.$X(e)))}finish(e=!0){return this._finish(),new Kn(this.chunks,this.BOM,this.cr,this.lf,this.crlf,this.containsRTL,this.containsUnusualLineTerminators,this.isBasicASCII,e)}_finish(){if(0===this.chunks.length&&this._acceptChunk1("",!0),this._hasPreviousChar){this._hasPreviousChar=!1;const e=this.chunks[this.chunks.length-1];e.buffer+=String.fromCharCode(this._previousChar);const t=zn(e.buffer);e.lineStarts=t,13===this._previousChar&&this.cr++}}}var Qn=n(6571),Jn=n(2083),Xn=n(1940),Yn=n(8381),Zn=n(4444);const er=new class{clone(){return this}equals(e){return this===e}};class tr{constructor(e){this._default=e,this._store=[]}get(e){return e=this._store.length;)this._store[this._store.length]=this._default;this._store[e]=t}replace(e,t,n){if(e>=this._store.length)return;if(0===t)return void this.insert(e,n);if(0===n)return void this.delete(e,t);const r=this._store.slice(0,e),i=this._store.slice(e+t),s=function(e,t){const n=[];for(let r=0;r=this._store.length||this._store.splice(e,t)}insert(e,t){if(0===t||e>=this._store.length)return;const n=[];for(let r=0;r0){const n=this._tokens[this._tokens.length-1];if(n.endLineNumber+1===e)return void n.appendLineTokens(t)}this._tokens.push(new nr(e,[t]))}finalize(){return this._tokens}}class ir{static{this.defaultTokenMetadata=33587200}static createEmpty(e,t){const n=ir.defaultTokenMetadata,r=new Uint32Array(2);return r[0]=e.length,r[1]=n,new ir(r,e,t)}static createFromTextAndMetadata(e,t){let n=0,r="";const i=new Array;for(const{text:s,metadata:o}of e)i.push(n+s.length,o),n+=s.length,r+=s;return new ir(new Uint32Array(i),r,t)}constructor(e,t,n){this._lineTokensBrand=void 0,this._tokens=e,this._tokensCount=this._tokens.length>>>1,this._text=t,this.languageIdCodec=n}equals(e){return e instanceof ir&&this.slicedEquals(e,0,this._tokensCount)}slicedEquals(e,t,n){if(this._text!==e._text)return!1;if(this._tokensCount!==e._tokensCount)return!1;const r=t<<1,i=r+(n<<1);for(let s=r;s0?this._tokens[e-1<<1]:0}getMetadata(e){return this._tokens[1+(e<<1)]}getLanguageId(e){const t=this._tokens[1+(e<<1)],n=Ye.x.getLanguageId(t);return this.languageIdCodec.decodeLanguageId(n)}getStandardTokenType(e){const t=this._tokens[1+(e<<1)];return Ye.x.getTokenType(t)}getForeground(e){const t=this._tokens[1+(e<<1)];return Ye.x.getForeground(t)}getClassName(e){const t=this._tokens[1+(e<<1)];return Ye.x.getClassNameFromMetadata(t)}getInlineStyle(e,t){const n=this._tokens[1+(e<<1)];return Ye.x.getInlineStyleFromMetadata(n,t)}getPresentation(e){const t=this._tokens[1+(e<<1)];return Ye.x.getPresentationFromMetadata(t)}getEndOffset(e){return this._tokens[e<<1]}findTokenIndexAtOffset(e){return ir.findIndexInTokensArray(this._tokens,e)}inflate(){return this}sliceAndInflate(e,t,n){return new sr(this,e,t,n)}static convertToEndOffset(e,t){const n=(e.length>>>1)-1;for(let r=0;r>>1)-1;for(;nt&&(r=i)}return n}withInserted(e){if(0===e.length)return this;let t=0,n=0,r="";const i=new Array;let s=0;for(;;){const o=ts){r+=this._text.substring(s,a.offset);const e=this._tokens[1+(t<<1)];i.push(r.length,e),s=a.offset}r+=a.text,i.push(r.length,a.tokenMetadata),n++}}return new ir(new Uint32Array(i),r,this.languageIdCodec)}getTokenText(e){const t=this.getStartOffset(e),n=this.getEndOffset(e);return this._text.substring(t,n)}forEach(e){const t=this.getCount();for(let n=0;n=n)break;this._tokensCount++}}getMetadata(e){return this._source.getMetadata(this._firstTokenIndex+e)}getLanguageId(e){return this._source.getLanguageId(this._firstTokenIndex+e)}getLineContent(){return this._source.getLineContent().substring(this._startOffset,this._endOffset)}equals(e){return e instanceof sr&&(this._startOffset===e._startOffset&&this._endOffset===e._endOffset&&this._deltaOffset===e._deltaOffset&&this._source.slicedEquals(e._source,this._firstTokenIndex,this._tokensCount))}getCount(){return this._tokensCount}getStandardTokenType(e){return this._source.getStandardTokenType(this._firstTokenIndex+e)}getForeground(e){return this._source.getForeground(this._firstTokenIndex+e)}getEndOffset(e){const t=this._source.getEndOffset(this._firstTokenIndex+e);return Math.min(this._endOffset,t)-this._startOffset+this._deltaOffset}getClassName(e){return this._source.getClassName(this._firstTokenIndex+e)}getInlineStyle(e,t){return this._source.getInlineStyle(this._firstTokenIndex+e,t)}getPresentation(e){return this._source.getPresentation(this._firstTokenIndex+e)}findTokenIndexAtOffset(e){return this._source.findTokenIndexAtOffset(e+this._startOffset-this._deltaOffset)-this._firstTokenIndex}getTokenText(e){const t=this._firstTokenIndex+e,n=this._source.getStartOffset(t),r=this._source.getEndOffset(t);let i=this._source.getTokenText(t);return nthis._endOffset&&(i=i.substring(0,i.length-(r-this._endOffset))),i}forEach(e){for(let t=0;tt)break;const i=this._textModel.getLineContent(r.lineNumber),s=ur(this._languageIdCodec,n,this.tokenizationSupport,i,!0,r.startState);e.add(r.lineNumber,s.tokens),this.store.setEndState(r.lineNumber,s.endState)}}getTokenTypeIfInsertingCharacter(e,t){const n=this.getStartState(e.lineNumber);if(!n)return 0;const r=this._textModel.getLanguageId(),i=this._textModel.getLineContent(e.lineNumber),s=i.substring(0,e.column-1)+t+i.substring(e.column-1),o=ur(this._languageIdCodec,r,this.tokenizationSupport,s,!0,n),a=new ir(o.tokens,s,this._languageIdCodec);if(0===a.getCount())return 0;const l=a.findTokenIndexAtOffset(e.column-1);return a.getStandardTokenType(l)}tokenizeLineWithEdit(e,t,n){const r=e.lineNumber,i=e.column,s=this.getStartState(r);if(!s)return null;const o=this._textModel.getLineContent(r),a=o.substring(0,i-1)+n+o.substring(i-1+t),l=this._textModel.getLanguageIdAtPosition(r,0),c=ur(this._languageIdCodec,l,this.tokenizationSupport,a,!0,s);return new ir(c.tokens,a,this._languageIdCodec)}hasAccurateTokensForLine(e){return e1&&o>=1;o--){const e=this._textModel.getLineFirstNonWhitespaceColumn(o);if(0!==e&&(e0&&n>0&&(n--,t--),this._lineEndStates.replace(e.startLineNumber,n,t)}}class hr{constructor(){this._ranges=[]}get min(){return 0===this._ranges.length?null:this._ranges[0].start}delete(e){const t=this._ranges.findIndex((t=>t.contains(e)));if(-1!==t){const n=this._ranges[t];n.start===e?n.endExclusive===e+1?this._ranges.splice(t,1):this._ranges[t]=new Zn.L(e+1,n.endExclusive):n.endExclusive===e+1?this._ranges[t]=new Zn.L(n.start,e):this._ranges.splice(t,1,new Zn.L(n.start,e),new Zn.L(e+1,n.endExclusive))}}addRange(e){Zn.L.addRange(e,this._ranges)}addRangeAndResize(e,t){let n=0;for(;!(n>=this._ranges.length||e.start<=this._ranges[n].endExclusive);)n++;let r=n;for(;!(r>=this._ranges.length||e.endExclusivee.toString())).join(" + ")}}function ur(e,t,n,r,i,s){let o=null;if(n)try{o=n.tokenizeEncoded(r,i,s.clone())}catch(a){(0,l.dz)(a)}return o||(o=function(e,t){const n=new Uint32Array(2);return n[0]=0,n[1]=(32768|e|2<<24)>>>0,new Jn.rY(n,null===t?er:t)}(e.encodeLanguageId(t),s)),ir.convertToEndOffset(o.tokens,r.length),o}class dr{constructor(e,t){this._tokenizerWithStateStore=e,this._backgroundTokenStore=t,this._isDisposed=!1,this._isScheduled=!1}dispose(){this._isDisposed=!0}handleChanges(){this._beginBackgroundTokenization()}_beginBackgroundTokenization(){!this._isScheduled&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._isScheduled=!0,(0,Xn.$6)((e=>{this._isScheduled=!1,this._backgroundTokenizeWithDeadline(e)})))}_backgroundTokenizeWithDeadline(e){const t=Date.now()+e.timeRemaining(),n=()=>{!this._isDisposed&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._backgroundTokenizeForAtLeast1ms(),Date.now()1)break;if(this._tokenizeOneInvalidLine(t)>=e)break}while(this._hasLinesToTokenize());this._backgroundTokenStore.setTokens(t.finalize()),this.checkFinished()}_hasLinesToTokenize(){return!!this._tokenizerWithStateStore&&!this._tokenizerWithStateStore.store.allStatesValid()}_tokenizeOneInvalidLine(e){const t=this._tokenizerWithStateStore?.getFirstInvalidLine();return t?(this._tokenizerWithStateStore.updateTokensUntilLine(e,t.lineNumber),t.lineNumber):this._tokenizerWithStateStore._textModel.getLineCount()+1}checkFinished(){this._isDisposed||this._tokenizerWithStateStore.store.allStatesValid()&&this._backgroundTokenStore.backgroundTokenizationFinished()}requestTokens(e,t){this._tokenizerWithStateStore.store.invalidateEndStateRange(new Qn.M(e,t))}}class gr{constructor(){this._onDidChangeVisibleRanges=new r.vl,this.onDidChangeVisibleRanges=this._onDidChangeVisibleRanges.event,this._views=new Set}attachView(){const e=new fr((t=>{this._onDidChangeVisibleRanges.fire({view:e,state:t})}));return this._views.add(e),e}detachView(e){this._views.delete(e),this._onDidChangeVisibleRanges.fire({view:e,state:void 0})}}class fr{constructor(e){this.handleStateChange=e}setVisibleLines(e,t){const n=e.map((e=>new Qn.M(e.startLineNumber,e.endLineNumber+1)));this.handleStateChange({visibleLineRanges:n,stabilized:t})}}class mr extends i.jG{get lineRanges(){return this._lineRanges}constructor(e){super(),this._refreshTokens=e,this.runner=this._register(new Xn.uC((()=>this.update()),50)),this._computedLineRanges=[],this._lineRanges=[]}update(){(0,o.aI)(this._computedLineRanges,this._lineRanges,((e,t)=>e.equals(t)))||(this._computedLineRanges=this._lineRanges,this._refreshTokens())}handleStateChange(e){this._lineRanges=e.visibleLineRanges,e.stabilized?(this.runner.cancel(),this.update()):this.runner.schedule()}}class pr extends i.jG{get backgroundTokenizationState(){return this._backgroundTokenizationState}constructor(e,t,n){super(),this._languageIdCodec=e,this._textModel=t,this.getLanguageId=n,this._backgroundTokenizationState=1,this._onDidChangeBackgroundTokenizationState=this._register(new r.vl),this.onDidChangeBackgroundTokenizationState=this._onDidChangeBackgroundTokenizationState.event,this._onDidChangeTokens=this._register(new r.vl),this.onDidChangeTokens=this._onDidChangeTokens.event}tokenizeIfCheap(e){this.isCheapToTokenize(e)&&this.forceTokenization(e)}}class br extends pr{constructor(e,t,n,r){super(t,n,r),this._treeSitterService=e,this._tokenizationSupport=null,this._initialize()}_initialize(){const e=this.getLanguageId();this._tokenizationSupport&&this._lastLanguageId===e||(this._lastLanguageId=e,this._tokenizationSupport=Jn.OB.get(e))}getLineTokens(e){const t=this._textModel.getLineContent(e);if(this._tokenizationSupport){const n=this._tokenizationSupport.tokenizeEncoded(e,this._textModel);if(n)return new ir(n,t,this._languageIdCodec)}return ir.createEmpty(t,this._languageIdCodec)}resetTokenization(e=!0){e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]}),this._initialize()}handleDidChangeAttached(){}handleDidChangeContent(e){e.isFlush&&this.resetTokenization(!1)}forceTokenization(e){}hasAccurateTokensForLine(e){return!0}isCheapToTokenize(e){return!0}getTokenTypeIfInsertingCharacter(e,t,n){return 0}tokenizeLineWithEdit(e,t,n){return null}get hasTokens(){return void 0!==this._treeSitterService.getParseResult(this._textModel)}}var _r=n(4432);const kr=new Uint32Array(0).buffer;class vr{static deleteBeginning(e,t){return null===e||e===kr?e:vr.delete(e,0,t)}static deleteEnding(e,t){if(null===e||e===kr)return e;const n=Cr(e),r=n[n.length-2];return vr.delete(e,t,r)}static delete(e,t,n){if(null===e||e===kr||t===n)return e;const r=Cr(e),i=r.length>>>1;if(0===t&&r[r.length-2]===n)return kr;const s=ir.findIndexInTokensArray(r,t),o=s>0?r[s-1<<1]:0;if(nl&&(r[a++]=e,r[a++]=r[1+(u<<1)],l=e)}if(a===r.length)return e;const h=new Uint32Array(a);return h.set(r.subarray(0,a),0),h.buffer}static append(e,t){if(t===kr)return e;if(e===kr)return t;if(null===e)return e;if(null===t)return null;const n=Cr(e),r=Cr(t),i=r.length>>>1,s=new Uint32Array(n.length+r.length);s.set(n,0);let o=n.length;const a=n[n.length-2];for(let l=0;l>>1;let s=ir.findIndexInTokensArray(r,t);if(s>0){r[s-1<<1]===t&&s--}for(let o=s;o0}getTokens(e,t,n){let r=null;if(t1&&(t=Ye.x.getLanguageId(r[1])!==e),!t)return kr}if(!r||0===r.length){const n=new Uint32Array(2);return n[0]=t,n[1]=Lr(e),n.buffer}return r[r.length-2]=t,0===r.byteOffset&&r.byteLength===r.buffer.byteLength?r.buffer:r}_ensureLine(e){for(;e>=this._len;)this._lineTokens[this._len]=null,this._len++}_deleteLines(e,t){0!==t&&(e+t>this._len&&(t=this._len-e),this._lineTokens.splice(e,t),this._len-=t)}_insertLines(e,t){if(0===t)return;const n=[];for(let r=0;r=this._len)return;if(e.startLineNumber===e.endLineNumber){if(e.startColumn===e.endColumn)return;return void(this._lineTokens[t]=vr.delete(this._lineTokens[t],e.startColumn-1,e.endColumn-1))}this._lineTokens[t]=vr.deleteEnding(this._lineTokens[t],e.startColumn-1);const n=e.endLineNumber-1;let r=null;n=this._len||(0!==t?(this._lineTokens[r]=vr.deleteEnding(this._lineTokens[r],e.column-1),this._lineTokens[r]=vr.insert(this._lineTokens[r],e.column-1,n),this._insertLines(e.lineNumber,t)):this._lineTokens[r]=vr.insert(this._lineTokens[r],e.column-1,n))}setMultilineTokens(e,t){if(0===e.length)return{changes:[]};const n=[];for(let r=0,i=e.length;r>>0}class wr{constructor(e){this._pieces=[],this._isComplete=!1,this._languageIdCodec=e}flush(){this._pieces=[],this._isComplete=!1}isEmpty(){return 0===this._pieces.length}set(e,t){this._pieces=e||[],this._isComplete=t}setPartial(e,t){let n=e;if(t.length>0){const r=t[0].getRange(),i=t[t.length-1].getRange();if(!r||!i)return e;n=e.plusRange(r).plusRange(i)}let r=null;for(let i=0,s=this._pieces.length;in.endLineNumber){r=r||{index:i};break}if(e.removeTokens(n),e.isEmpty()){this._pieces.splice(i,1),i--,s--;continue}if(e.endLineNumbern.endLineNumber){r=r||{index:i};continue}const[t,o]=e.split(n);t.isEmpty()?r=r||{index:i}:o.isEmpty()||(this._pieces.splice(i,1,t,o),i++,s++,r=r||{index:i})}return r=r||{index:this._pieces.length},t.length>0&&(this._pieces=o.nK(this._pieces,r.index,t)),n}isComplete(){return this._isComplete}addSparseTokens(e,t){if(0===t.getLineContent().length)return t;const n=this._pieces;if(0===n.length)return t;const r=n[wr._findFirstPieceWithLine(n,e)].getLineTokens(e);if(!r)return t;const i=t.getCount(),s=r.getCount();let o=0;const a=[];let l=0,c=0;const h=(e,t)=>{e!==c&&(c=e,a[l++]=e,a[l++]=t)};for(let u=0;u>>0,l=~a>>>0;for(;ot)){for(;i>n&&e[i-1].startLineNumber<=t&&t<=e[i-1].endLineNumber;)i--;return i}r=i-1}}return n}acceptEdit(e,t,n,r,i){for(const s of this._pieces)s.acceptEdit(e,t,n,r,i)}}var Sr,xr=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},Er=function(e,t){return function(n,r){t(n,r,e)}};let Nr=Sr=class extends Ut{constructor(e,t,n,s,o,a,l){super(),this._textModel=e,this._bracketPairsTextModelPart=t,this._languageId=n,this._attachedViews=s,this._languageService=o,this._languageConfigurationService=a,this._treeSitterService=l,this._semanticTokens=new wr(this._languageService.languageIdCodec),this._onDidChangeLanguage=this._register(new r.vl),this.onDidChangeLanguage=this._onDidChangeLanguage.event,this._onDidChangeLanguageConfiguration=this._register(new r.vl),this.onDidChangeLanguageConfiguration=this._onDidChangeLanguageConfiguration.event,this._onDidChangeTokens=this._register(new r.vl),this.onDidChangeTokens=this._onDidChangeTokens.event,this._tokensDisposables=this._register(new i.Cm),this._register(this._languageConfigurationService.onDidChange((e=>{e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}))),this._register(r.Jh.filter(Jn.OB.onDidChange,(e=>e.changedLanguages.includes(this._languageId)))((()=>{this.createPreferredTokenProvider()}))),this.createPreferredTokenProvider()}createGrammarTokens(){return this._register(new Tr(this._languageService.languageIdCodec,this._textModel,(()=>this._languageId),this._attachedViews))}createTreeSitterTokens(){return this._register(new br(this._treeSitterService,this._languageService.languageIdCodec,this._textModel,(()=>this._languageId)))}createTokens(e){const t=void 0!==this._tokens;this._tokens?.dispose(),this._tokens=e?this.createTreeSitterTokens():this.createGrammarTokens(),this._tokensDisposables.clear(),this._tokensDisposables.add(this._tokens.onDidChangeTokens((e=>{this._emitModelTokensChangedEvent(e)}))),this._tokensDisposables.add(this._tokens.onDidChangeBackgroundTokenizationState((e=>{this._bracketPairsTextModelPart.handleDidChangeBackgroundTokenizationState()}))),t&&this._tokens.resetTokenization()}createPreferredTokenProvider(){Jn.OB.get(this._languageId)?this._tokens instanceof br||this.createTokens(!0):this._tokens instanceof Tr||this.createTokens(!1)}handleLanguageConfigurationServiceChange(e){e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}handleDidChangeContent(e){if(e.isFlush)this._semanticTokens.flush();else if(!e.isEolChange)for(const t of e.changes){const[e,n,r]=(0,u.W)(t.text);this._semanticTokens.acceptEdit(t.range,e,n,r,t.text.length>0?t.text.charCodeAt(0):0)}this._tokens.handleDidChangeContent(e)}handleDidChangeAttached(){this._tokens.handleDidChangeAttached()}getLineTokens(e){this.validateLineNumber(e);const t=this._tokens.getLineTokens(e);return this._semanticTokens.addSparseTokens(e,t)}_emitModelTokensChangedEvent(e){this._textModel._isDisposing()||(this._bracketPairsTextModelPart.handleDidChangeTokens(e),this._onDidChangeTokens.fire(e))}validateLineNumber(e){if(e<1||e>this._textModel.getLineCount())throw new l.D7("Illegal value for lineNumber")}get hasTokens(){return this._tokens.hasTokens}resetTokenization(){this._tokens.resetTokenization()}get backgroundTokenizationState(){return this._tokens.backgroundTokenizationState}forceTokenization(e){this.validateLineNumber(e),this._tokens.forceTokenization(e)}hasAccurateTokensForLine(e){return this.validateLineNumber(e),this._tokens.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return this.validateLineNumber(e),this._tokens.isCheapToTokenize(e)}tokenizeIfCheap(e){this.validateLineNumber(e),this._tokens.tokenizeIfCheap(e)}getTokenTypeIfInsertingCharacter(e,t,n){return this._tokens.getTokenTypeIfInsertingCharacter(e,t,n)}tokenizeLineWithEdit(e,t,n){return this._tokens.tokenizeLineWithEdit(e,t,n)}setSemanticTokens(e,t){this._semanticTokens.set(e,t),this._emitModelTokensChangedEvent({semanticTokensApplied:null!==e,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]})}hasCompleteSemanticTokens(){return this._semanticTokens.isComplete()}hasSomeSemanticTokens(){return!this._semanticTokens.isEmpty()}setPartialSemanticTokens(e,t){if(this.hasCompleteSemanticTokens())return;const n=this._textModel.validateRange(this._semanticTokens.setPartial(e,t));this._emitModelTokensChangedEvent({semanticTokensApplied:!0,ranges:[{fromLineNumber:n.startLineNumber,toLineNumber:n.endLineNumber}]})}getWordAtPosition(e){this.assertNotDisposed();const t=this._textModel.validatePosition(e),n=this._textModel.getLineContent(t.lineNumber),r=this.getLineTokens(t.lineNumber),i=r.findTokenIndexAtOffset(t.column-1),[s,o]=Sr._findLanguageBoundaries(r,i),a=(0,v.Th)(t.column,this.getLanguageConfiguration(r.getLanguageId(i)).getWordDefinition(),n.substring(s,o),s);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a;if(i>0&&s===t.column-1){const[s,o]=Sr._findLanguageBoundaries(r,i-1),a=(0,v.Th)(t.column,this.getLanguageConfiguration(r.getLanguageId(i-1)).getWordDefinition(),n.substring(s,o),s);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a}return null}getLanguageConfiguration(e){return this._languageConfigurationService.getLanguageConfiguration(e)}static _findLanguageBoundaries(e,t){const n=e.getLanguageId(t);let r=0;for(let s=t;s>=0&&e.getLanguageId(s)===n;s--)r=e.getStartOffset(s);let i=e.getLineContent().length;for(let s=t,o=e.getCount();s{const t=this.getLanguageId();-1!==e.changedLanguages.indexOf(t)&&this.resetTokenization()}))),this.resetTokenization(),this._register(r.onDidChangeVisibleRanges((({view:e,state:t})=>{if(t){let n=this._attachedViewStates.get(e);n||(n=new mr((()=>this.refreshRanges(n.lineRanges))),this._attachedViewStates.set(e,n)),n.handleStateChange(t)}else this._attachedViewStates.deleteAndDispose(e)})))}resetTokenization(e=!0){this._tokens.flush(),this._debugBackgroundTokens?.flush(),this._debugBackgroundStates&&(this._debugBackgroundStates=new lr(this._textModel.getLineCount())),e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]});const[t,n]=(()=>{if(this._textModel.isTooLargeForTokenization())return[null,null];const e=Jn.dG.get(this.getLanguageId());if(!e)return[null,null];let t;try{t=e.getInitialState()}catch(n){return(0,l.dz)(n),[null,null]}return[e,t]})();if(this._tokenizer=t&&n?new ar(this._textModel.getLineCount(),t,this._textModel,this._languageIdCodec):null,this._backgroundTokenizer.clear(),this._defaultBackgroundTokenizer=null,this._tokenizer){const e={setTokens:e=>{this.setTokens(e)},backgroundTokenizationFinished:()=>{if(2===this._backgroundTokenizationState)return;this._backgroundTokenizationState=2,this._onDidChangeBackgroundTokenizationState.fire()},setEndState:(e,t)=>{if(!this._tokenizer)return;const n=this._tokenizer.store.getFirstInvalidEndStateLineNumber();null!==n&&e>=n&&this._tokenizer?.store.setEndState(e,t)}};t&&t.createBackgroundTokenizer&&!t.backgroundTokenizerShouldOnlyVerifyTokens&&(this._backgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,e)),this._backgroundTokenizer.value||this._textModel.isTooLargeForTokenization()||(this._backgroundTokenizer.value=this._defaultBackgroundTokenizer=new dr(this._tokenizer,e),this._defaultBackgroundTokenizer.handleChanges()),t?.backgroundTokenizerShouldOnlyVerifyTokens&&t.createBackgroundTokenizer?(this._debugBackgroundTokens=new yr(this._languageIdCodec),this._debugBackgroundStates=new lr(this._textModel.getLineCount()),this._debugBackgroundTokenizer.clear(),this._debugBackgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,{setTokens:e=>{this._debugBackgroundTokens?.setMultilineTokens(e,this._textModel)},backgroundTokenizationFinished(){},setEndState:(e,t)=>{this._debugBackgroundStates?.setEndState(e,t)}})):(this._debugBackgroundTokens=void 0,this._debugBackgroundStates=void 0,this._debugBackgroundTokenizer.value=void 0)}this.refreshAllVisibleLineTokens()}handleDidChangeAttached(){this._defaultBackgroundTokenizer?.handleChanges()}handleDidChangeContent(e){if(e.isFlush)this.resetTokenization(!1);else if(!e.isEolChange){for(const t of e.changes){const[e,n]=(0,u.W)(t.text);this._tokens.acceptEdit(t.range,e,n),this._debugBackgroundTokens?.acceptEdit(t.range,e,n)}this._debugBackgroundStates?.acceptChanges(e.changes),this._tokenizer&&this._tokenizer.store.acceptChanges(e.changes),this._defaultBackgroundTokenizer?.handleChanges()}}setTokens(e){const{changes:t}=this._tokens.setMultilineTokens(e,this._textModel);return t.length>0&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:t}),{changes:t}}refreshAllVisibleLineTokens(){const e=Qn.M.joinMany([...this._attachedViewStates].map((([e,t])=>t.lineRanges)));this.refreshRanges(e)}refreshRanges(e){for(const t of e)this.refreshRange(t.startLineNumber,t.endLineNumberExclusive-1)}refreshRange(e,t){if(!this._tokenizer)return;e=Math.max(1,Math.min(this._textModel.getLineCount(),e)),t=Math.min(this._textModel.getLineCount(),t);const n=new rr,{heuristicTokens:r}=this._tokenizer.tokenizeHeuristically(n,e,t),i=this.setTokens(n.finalize());if(r)for(const s of i.changes)this._backgroundTokenizer.value?.requestTokens(s.fromLineNumber,s.toLineNumber+1);this._defaultBackgroundTokenizer?.checkFinished()}forceTokenization(e){const t=new rr;this._tokenizer?.updateTokensUntilLine(t,e),this.setTokens(t.finalize()),this._defaultBackgroundTokenizer?.checkFinished()}hasAccurateTokensForLine(e){return!this._tokenizer||this._tokenizer.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return!this._tokenizer||this._tokenizer.isCheapToTokenize(e)}getLineTokens(e){const t=this._textModel.getLineContent(e),n=this._tokens.getTokens(this._textModel.getLanguageId(),e-1,t);if(this._debugBackgroundTokens&&this._debugBackgroundStates&&this._tokenizer&&this._debugBackgroundStates.getFirstInvalidEndStateLineNumberOrMax()>e&&this._tokenizer.store.getFirstInvalidEndStateLineNumberOrMax()>e){const r=this._debugBackgroundTokens.getTokens(this._textModel.getLanguageId(),e-1,t);!n.equals(r)&&this._debugBackgroundTokenizer.value?.reportMismatchingTokens&&this._debugBackgroundTokenizer.value.reportMismatchingTokens(e)}return n}getTokenTypeIfInsertingCharacter(e,t,n){if(!this._tokenizer)return 0;const r=this._textModel.validatePosition(new f.y(e,t));return this.forceTokenization(r.lineNumber),this._tokenizer.getTokenTypeIfInsertingCharacter(r,n)}tokenizeLineWithEdit(e,t,n){if(!this._tokenizer)return null;const r=this._textModel.validatePosition(e);return this.forceTokenization(r.lineNumber),this._tokenizer.tokenizeLineWithEdit(r,t,n)}get hasTokens(){return this._tokens.hasTokens}}class Ar{constructor(){this.changeType=1}}class Ir{static applyInjectedText(e,t){if(!t||0===t.length)return e;let n="",r=0;for(const i of t)n+=e.substring(r,i.column-1),r=i.column-1,n+=i.options.content;return n+=e.substring(r),n}static fromDecorations(e){const t=[];for(const n of e)n.options.before&&n.options.before.content.length>0&&t.push(new Ir(n.ownerId,n.range.startLineNumber,n.range.startColumn,n.options.before,0)),n.options.after&&n.options.after.content.length>0&&t.push(new Ir(n.ownerId,n.range.endLineNumber,n.range.endColumn,n.options.after,1));return t.sort(((e,t)=>e.lineNumber===t.lineNumber?e.column===t.column?e.order-t.order:e.column-t.column:e.lineNumber-t.lineNumber)),t}constructor(e,t,n,r,i){this.ownerId=e,this.lineNumber=t,this.column=n,this.options=r,this.order=i}}class Or{constructor(e,t,n){this.changeType=2,this.lineNumber=e,this.detail=t,this.injectedText=n}}class Mr{constructor(e,t){this.changeType=3,this.fromLineNumber=e,this.toLineNumber=t}}class Rr{constructor(e,t,n,r){this.changeType=4,this.injectedTexts=r,this.fromLineNumber=e,this.toLineNumber=t,this.detail=n}}class Dr{constructor(){this.changeType=5}}class Br{constructor(e,t,n,r){this.changes=e,this.versionId=t,this.isUndoing=n,this.isRedoing=r,this.resultingSelection=null}containsEvent(e){for(let t=0,n=this.changes.length;t=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},Ur=function(e,t){return function(n,r){t(n,r,e)}};function $r(e,t){let n;return n="string"===typeof e?function(e){const t=new Gn;return t.acceptChunk(e),t.finish()}(e):me.nk(e)?function(e){const t=new Gn;let n;for(;"string"===typeof(n=e.read());)t.acceptChunk(n);return t.finish()}(e):e,n.create(t)}let Hr=0;class Kr{constructor(e){this._source=e,this._eos=!1}read(){if(this._eos)return null;const e=[];let t=0,n=0;for(;;){const r=this._source.read();if(null===r)return this._eos=!0,0===t?null:e.join("");if(r.length>0&&(e[t++]=r,n+=r.length),n>=65536)return e.join("")}}}const Gr=()=>{throw new Error("Invalid change accessor")};let Qr=class extends i.jG{static{qr=this}static{this._MODEL_SYNC_LIMIT=52428800}static{this.LARGE_FILE_SIZE_THRESHOLD=20971520}static{this.LARGE_FILE_LINE_COUNT_THRESHOLD=3e5}static{this.LARGE_FILE_HEAP_OPERATION_THRESHOLD=268435456}static{this.DEFAULT_CREATION_OPTIONS={isForSimpleWidget:!1,tabSize:b.tabSize,indentSize:b.indentSize,insertSpaces:b.insertSpaces,detectIndentation:!1,defaultEOL:1,trimAutoWhitespace:b.trimAutoWhitespace,largeFileOptimizations:b.largeFileOptimizations,bracketPairColorizationOptions:b.bracketPairColorizationOptions}}static resolveOptions(e,t){if(t.detectIndentation){const n=Xt(e,t.tabSize,t.insertSpaces);return new me.X2({tabSize:n.tabSize,indentSize:"tabSize",insertSpaces:n.insertSpaces,trimAutoWhitespace:t.trimAutoWhitespace,defaultEOL:t.defaultEOL,bracketPairColorizationOptions:t.bracketPairColorizationOptions})}return new me.X2(t)}get onDidChangeLanguage(){return this._tokenizationTextModelPart.onDidChangeLanguage}get onDidChangeLanguageConfiguration(){return this._tokenizationTextModelPart.onDidChangeLanguageConfiguration}get onDidChangeTokens(){return this._tokenizationTextModelPart.onDidChangeTokens}onDidChangeContent(e){return this._eventEmitter.slowEvent((t=>e(t.contentChangedEvent)))}onDidChangeContentOrInjectedText(e){return(0,i.qE)(this._eventEmitter.fastEvent((t=>e(t))),this._onDidChangeInjectedText.event((t=>e(t))))}_isDisposing(){return this.__isDisposing}get tokenization(){return this._tokenizationTextModelPart}get bracketPairs(){return this._bracketPairs}get guides(){return this._guidesTextModelPart}constructor(e,t,n,s=null,o,a,l,u){super(),this._undoRedoService=o,this._languageService=a,this._languageConfigurationService=l,this.instantiationService=u,this._onWillDispose=this._register(new r.vl),this.onWillDispose=this._onWillDispose.event,this._onDidChangeDecorations=this._register(new li((e=>this.handleBeforeFireDecorationsChangedEvent(e)))),this.onDidChangeDecorations=this._onDidChangeDecorations.event,this._onDidChangeOptions=this._register(new r.vl),this.onDidChangeOptions=this._onDidChangeOptions.event,this._onDidChangeAttached=this._register(new r.vl),this.onDidChangeAttached=this._onDidChangeAttached.event,this._onDidChangeInjectedText=this._register(new r.vl),this._eventEmitter=this._register(new ci),this._languageSelectionListener=this._register(new i.HE),this._deltaDecorationCallCnt=0,this._attachedViews=new gr,Hr++,this.id="$model"+Hr,this.isForSimpleWidget=n.isForSimpleWidget,this._associatedResource="undefined"===typeof s||null===s?h.r.parse("inmemory://model/"+Hr):s,this._attachedEditorCount=0;const{textBuffer:d,disposable:g}=$r(e,n.defaultEOL);this._buffer=d,this._bufferDisposable=g,this._options=qr.resolveOptions(this._buffer,n);const f="string"===typeof t?t:t.languageId;"string"!==typeof t&&(this._languageSelectionListener.value=t.onDidChange((()=>this._setLanguage(t.languageId)))),this._bracketPairs=this._register(new yt(this,this._languageConfigurationService)),this._guidesTextModelPart=this._register(new Kt(this,this._languageConfigurationService)),this._decorationProvider=this._register(new Nt(this)),this._tokenizationTextModelPart=this.instantiationService.createInstance(Nr,this,this._bracketPairs,f,this._attachedViews);const p=this._buffer.getLineCount(),b=this._buffer.getValueLengthInRange(new m.Q(1,1,p,this._buffer.getLineLength(p)+1),0);n.largeFileOptimizations?(this._isTooLargeForTokenization=b>qr.LARGE_FILE_SIZE_THRESHOLD||p>qr.LARGE_FILE_LINE_COUNT_THRESHOLD,this._isTooLargeForHeapOperation=b>qr.LARGE_FILE_HEAP_OPERATION_THRESHOLD):(this._isTooLargeForTokenization=!1,this._isTooLargeForHeapOperation=!1),this._isTooLargeForSyncing=b>qr._MODEL_SYNC_LIMIT,this._versionId=1,this._alternativeVersionId=1,this._initialUndoRedoSnapshot=null,this._isDisposed=!1,this.__isDisposing=!1,this._instanceId=c.tk(Hr),this._lastDecorationId=0,this._decorations=Object.create(null),this._decorationsTree=new Yr,this._commandManager=new jt(this,this._undoRedoService),this._isUndoing=!1,this._isRedoing=!1,this._trimAutoWhitespaceLines=null,this._register(this._decorationProvider.onDidChange((()=>{this._onDidChangeDecorations.beginDeferredEmit(),this._onDidChangeDecorations.fire(),this._onDidChangeDecorations.endDeferredEmit()}))),this._languageService.requestRichLanguageFeatures(f),this._register(this._languageConfigurationService.onDidChange((e=>{this._bracketPairs.handleLanguageConfigurationServiceChange(e),this._tokenizationTextModelPart.handleLanguageConfigurationServiceChange(e)})))}dispose(){this.__isDisposing=!0,this._onWillDispose.fire(),this._tokenizationTextModelPart.dispose(),this._isDisposed=!0,super.dispose(),this._bufferDisposable.dispose(),this.__isDisposing=!1;const e=new Hn([],"","\n",!1,!1,!0,!0);e.dispose(),this._buffer=e,this._bufferDisposable=i.jG.None}_assertNotDisposed(){if(this._isDisposed)throw new l.D7("Model is disposed!")}_emitContentChangedEvent(e,t){this.__isDisposing||(this._tokenizationTextModelPart.handleDidChangeContent(t),this._bracketPairs.handleDidChangeContent(t),this._eventEmitter.fire(new Pr(e,t)))}setValue(e){if(this._assertNotDisposed(),null===e||void 0===e)throw(0,l.Qg)();const{textBuffer:t,disposable:n}=$r(e,this._options.defaultEOL);this._setValueFromTextBuffer(t,n)}_createContentChanged2(e,t,n,r,i,s,o,a){return{changes:[{range:e,rangeOffset:t,rangeLength:n,text:r}],eol:this._buffer.getEOL(),isEolChange:a,versionId:this.getVersionId(),isUndoing:i,isRedoing:s,isFlush:o}}_setValueFromTextBuffer(e,t){this._assertNotDisposed();const n=this.getFullModelRange(),r=this.getValueLengthInRange(n),i=this.getLineCount(),s=this.getLineMaxColumn(i);this._buffer=e,this._bufferDisposable.dispose(),this._bufferDisposable=t,this._increaseVersionId(),this._decorations=Object.create(null),this._decorationsTree=new Yr,this._commandManager.clear(),this._trimAutoWhitespaceLines=null,this._emitContentChangedEvent(new Br([new Ar],this._versionId,!1,!1),this._createContentChanged2(new m.Q(1,1,i,s),0,r,this.getValue(),!1,!1,!0,!1))}setEOL(e){this._assertNotDisposed();const t=1===e?"\r\n":"\n";if(this._buffer.getEOL()===t)return;const n=this.getFullModelRange(),r=this.getValueLengthInRange(n),i=this.getLineCount(),s=this.getLineMaxColumn(i);this._onBeforeEOLChange(),this._buffer.setEOL(t),this._increaseVersionId(),this._onAfterEOLChange(),this._emitContentChangedEvent(new Br([new Dr],this._versionId,!1,!1),this._createContentChanged2(new m.Q(1,1,i,s),0,r,this.getValue(),!1,!1,!1,!0))}_onBeforeEOLChange(){this._decorationsTree.ensureAllNodesHaveRanges(this)}_onAfterEOLChange(){const e=this.getVersionId(),t=this._decorationsTree.collectNodesPostOrder();for(let n=0,r=t.length;n0}getAttachedEditorCount(){return this._attachedEditorCount}isTooLargeForSyncing(){return this._isTooLargeForSyncing}isTooLargeForTokenization(){return this._isTooLargeForTokenization}isTooLargeForHeapOperation(){return this._isTooLargeForHeapOperation}isDisposed(){return this._isDisposed}isDominatedByLongLines(){if(this._assertNotDisposed(),this.isTooLargeForTokenization())return!1;let e=0,t=0;const n=this._buffer.getLineCount();for(let r=1;r<=n;r++){const n=this._buffer.getLineLength(r);n>=1e4?t+=n:e+=n}return t>e}get uri(){return this._associatedResource}getOptions(){return this._assertNotDisposed(),this._options}getFormattingOptions(){return{tabSize:this._options.indentSize,insertSpaces:this._options.insertSpaces}}updateOptions(e){this._assertNotDisposed();const t="undefined"!==typeof e.tabSize?e.tabSize:this._options.tabSize,n="undefined"!==typeof e.indentSize?e.indentSize:this._options.originalIndentSize,r="undefined"!==typeof e.insertSpaces?e.insertSpaces:this._options.insertSpaces,i="undefined"!==typeof e.trimAutoWhitespace?e.trimAutoWhitespace:this._options.trimAutoWhitespace,s="undefined"!==typeof e.bracketColorizationOptions?e.bracketColorizationOptions:this._options.bracketPairColorizationOptions,o=new me.X2({tabSize:t,indentSize:n,insertSpaces:r,defaultEOL:this._options.defaultEOL,trimAutoWhitespace:i,bracketPairColorizationOptions:s});if(this._options.equals(o))return;const a=this._options.createChangeEvent(o);this._options=o,this._bracketPairs.handleDidChangeOptions(a),this._decorationProvider.handleDidChangeOptions(a),this._onDidChangeOptions.fire(a)}detectIndentation(e,t){this._assertNotDisposed();const n=Xt(this._buffer,t,e);this.updateOptions({insertSpaces:n.insertSpaces,tabSize:n.tabSize,indentSize:n.tabSize})}normalizeIndentation(e){return this._assertNotDisposed(),g(e,this._options.indentSize,this._options.insertSpaces)}getVersionId(){return this._assertNotDisposed(),this._versionId}mightContainRTL(){return this._buffer.mightContainRTL()}mightContainUnusualLineTerminators(){return this._buffer.mightContainUnusualLineTerminators()}removeUnusualLineTerminators(e=null){const t=this.findMatches(c._J.source,!1,!0,!1,null,!1,1073741824);this._buffer.resetMightContainUnusualLineTerminators(),this.pushEditOperations(e,t.map((e=>({range:e.range,text:null}))),(()=>null))}mightContainNonBasicASCII(){return this._buffer.mightContainNonBasicASCII()}getAlternativeVersionId(){return this._assertNotDisposed(),this._alternativeVersionId}getInitialUndoRedoSnapshot(){return this._assertNotDisposed(),this._initialUndoRedoSnapshot}getOffsetAt(e){this._assertNotDisposed();const t=this._validatePosition(e.lineNumber,e.column,0);return this._buffer.getOffsetAt(t.lineNumber,t.column)}getPositionAt(e){this._assertNotDisposed();const t=Math.min(this._buffer.getLength(),Math.max(0,e));return this._buffer.getPositionAt(t)}_increaseVersionId(){this._versionId=this._versionId+1,this._alternativeVersionId=this._versionId}_overwriteVersionId(e){this._versionId=e}_overwriteAlternativeVersionId(e){this._alternativeVersionId=e}_overwriteInitialUndoRedoSnapshot(e){this._initialUndoRedoSnapshot=e}getValue(e,t=!1){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new l.D7("Operation would exceed heap memory limits");const n=this.getFullModelRange(),r=this.getValueInRange(n,e);return t?this._buffer.getBOM()+r:r}createSnapshot(e=!1){return new Kr(this._buffer.createSnapshot(e))}getValueLength(e,t=!1){this._assertNotDisposed();const n=this.getFullModelRange(),r=this.getValueLengthInRange(n,e);return t?this._buffer.getBOM().length+r:r}getValueInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueInRange(this.validateRange(e),t)}getValueLengthInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueLengthInRange(this.validateRange(e),t)}getCharacterCountInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getCharacterCountInRange(this.validateRange(e),t)}getLineCount(){return this._assertNotDisposed(),this._buffer.getLineCount()}getLineContent(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineContent(e)}getLineLength(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)}getLinesContent(){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new l.D7("Operation would exceed heap memory limits");return this._buffer.getLinesContent()}getEOL(){return this._assertNotDisposed(),this._buffer.getEOL()}getEndOfLineSequence(){return this._assertNotDisposed(),"\n"===this._buffer.getEOL()?0:1}getLineMinColumn(e){return this._assertNotDisposed(),1}getLineMaxColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)+1}getLineFirstNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineFirstNonWhitespaceColumn(e)}getLineLastNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new l.D7("Illegal value for lineNumber");return this._buffer.getLineLastNonWhitespaceColumn(e)}_validateRangeRelaxedNoAllocations(e){const t=this._buffer.getLineCount(),n=e.startLineNumber,r=e.startColumn;let i=Math.floor("number"!==typeof n||isNaN(n)?1:n),s=Math.floor("number"!==typeof r||isNaN(r)?1:r);if(i<1)i=1,s=1;else if(i>t)i=t,s=this.getLineMaxColumn(i);else if(s<=1)s=1;else{const e=this.getLineMaxColumn(i);s>=e&&(s=e)}const o=e.endLineNumber,a=e.endColumn;let l=Math.floor("number"!==typeof o||isNaN(o)?1:o),c=Math.floor("number"!==typeof a||isNaN(a)?1:a);if(l<1)l=1,c=1;else if(l>t)l=t,c=this.getLineMaxColumn(l);else if(c<=1)c=1;else{const e=this.getLineMaxColumn(l);c>=e&&(c=e)}return n===i&&r===s&&o===l&&a===c&&e instanceof m.Q&&!(e instanceof p.L)?e:new m.Q(i,s,l,c)}_isValidPosition(e,t,n){if("number"!==typeof e||"number"!==typeof t)return!1;if(isNaN(e)||isNaN(t))return!1;if(e<1||t<1)return!1;if((0|e)!==e||(0|t)!==t)return!1;if(e>this._buffer.getLineCount())return!1;if(1===t)return!0;if(t>this.getLineMaxColumn(e))return!1;if(1===n){const n=this._buffer.getLineCharCode(e,t-2);if(c.pc(n))return!1}return!0}_validatePosition(e,t,n){const r=Math.floor("number"!==typeof e||isNaN(e)?1:e),i=Math.floor("number"!==typeof t||isNaN(t)?1:t),s=this._buffer.getLineCount();if(r<1)return new f.y(1,1);if(r>s)return new f.y(s,this.getLineMaxColumn(s));if(i<=1)return new f.y(r,1);const o=this.getLineMaxColumn(r);if(i>=o)return new f.y(r,o);if(1===n){const e=this._buffer.getLineCharCode(r,i-2);if(c.pc(e))return new f.y(r,i-1)}return new f.y(r,i)}validatePosition(e){return this._assertNotDisposed(),e instanceof f.y&&this._isValidPosition(e.lineNumber,e.column,1)?e:this._validatePosition(e.lineNumber,e.column,1)}_isValidRange(e,t){const n=e.startLineNumber,r=e.startColumn,i=e.endLineNumber,s=e.endColumn;if(!this._isValidPosition(n,r,0))return!1;if(!this._isValidPosition(i,s,0))return!1;if(1===t){const e=r>1?this._buffer.getLineCharCode(n,r-2):0,t=s>1&&s<=this._buffer.getLineLength(i)?this._buffer.getLineCharCode(i,s-2):0,o=c.pc(e),a=c.pc(t);return!o&&!a}return!0}validateRange(e){if(this._assertNotDisposed(),e instanceof m.Q&&!(e instanceof p.L)&&this._isValidRange(e,1))return e;const t=this._validatePosition(e.startLineNumber,e.startColumn,0),n=this._validatePosition(e.endLineNumber,e.endColumn,0),r=t.lineNumber,i=t.column,s=n.lineNumber,o=n.column;{const e=i>1?this._buffer.getLineCharCode(r,i-2):0,t=o>1&&o<=this._buffer.getLineLength(s)?this._buffer.getLineCharCode(s,o-2):0,n=c.pc(e),a=c.pc(t);return n||a?r===s&&i===o?new m.Q(r,i-1,s,o-1):n&&a?new m.Q(r,i-1,s,o+1):n?new m.Q(r,i-1,s,o):new m.Q(r,i,s,o+1):new m.Q(r,i,s,o)}}modifyPosition(e,t){this._assertNotDisposed();const n=this.getOffsetAt(e)+t;return this.getPositionAt(Math.min(this._buffer.getLength(),Math.max(0,n)))}getFullModelRange(){this._assertNotDisposed();const e=this.getLineCount();return new m.Q(1,1,e,this.getLineMaxColumn(e))}findMatchesLineByLine(e,t,n,r){return this._buffer.findMatchesLineByLine(e,t,n,r)}findMatches(e,t,n,r,i,s,o=999){this._assertNotDisposed();let a=null;null!==t&&(Array.isArray(t)||(t=[t]),t.every((e=>m.Q.isIRange(e)))&&(a=t.map((e=>this.validateRange(e))))),null===a&&(a=[this.getFullModelRange()]),a=a.sort(((e,t)=>e.startLineNumber-t.startLineNumber||e.startColumn-t.startColumn));const l=[];let c;if(l.push(a.reduce(((e,t)=>m.Q.areIntersecting(e,t)?e.plusRange(t):(l.push(e),t)))),!n&&e.indexOf("\n")<0){const t=new Bn.lt(e,n,r,i).parseSearchRequest();if(!t)return[];c=e=>this.findMatchesLineByLine(e,t,s,o)}else c=t=>Bn.hB.findMatches(this,new Bn.lt(e,n,r,i),t,s,o);return l.map(c).reduce(((e,t)=>e.concat(t)),[])}findNextMatch(e,t,n,r,i,s){this._assertNotDisposed();const o=this.validatePosition(t);if(!n&&e.indexOf("\n")<0){const t=new Bn.lt(e,n,r,i).parseSearchRequest();if(!t)return null;const a=this.getLineCount();let l=new m.Q(o.lineNumber,o.column,a,this.getLineMaxColumn(a)),c=this.findMatchesLineByLine(l,t,s,1);return Bn.hB.findNextMatch(this,new Bn.lt(e,n,r,i),o,s),c.length>0?c[0]:(l=new m.Q(1,1,o.lineNumber,this.getLineMaxColumn(o.lineNumber)),c=this.findMatchesLineByLine(l,t,s,1),c.length>0?c[0]:null)}return Bn.hB.findNextMatch(this,new Bn.lt(e,n,r,i),o,s)}findPreviousMatch(e,t,n,r,i,s){this._assertNotDisposed();const o=this.validatePosition(t);return Bn.hB.findPreviousMatch(this,new Bn.lt(e,n,r,i),o,s)}pushStackElement(){this._commandManager.pushStackElement()}popStackElement(){this._commandManager.popStackElement()}pushEOL(e){if(("\n"===this.getEOL()?0:1)!==e)try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEOL(e)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_validateEditOperation(e){return e instanceof me.Wo?e:new me.Wo(e.identifier||null,this.validateRange(e.range),e.text,e.forceMoveMarkers||!1,e.isAutoWhitespaceEdit||!1,e._isTracked||!1)}_validateEditOperations(e){const t=[];for(let n=0,r=e.length;n({range:this.validateRange(e.range),text:e.text})));let r=!0;if(e)for(let t=0,i=e.length;ti.endLineNumber,o=i.startLineNumber>t.endLineNumber;if(!r&&!o){s=!0;break}}if(!s){r=!1;break}}if(r)for(let e=0,i=this._trimAutoWhitespaceLines.length;et.endLineNumber)&&(!(r===t.startLineNumber&&t.startColumn===i&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(0))&&!(r===t.startLineNumber&&1===t.startColumn&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(o.length-1)))){s=!1;break}}if(s){const e=new m.Q(r,1,r,i);t.push(new me.Wo(null,e,null,!1,!1,!1))}}this._trimAutoWhitespaceLines=null}return null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEditOperation(e,t,n,r)}_applyUndo(e,t,n,r){const i=e.map((e=>{const t=this.getPositionAt(e.newPosition),n=this.getPositionAt(e.newEnd);return{range:new m.Q(t.lineNumber,t.column,n.lineNumber,n.column),text:e.oldText}}));this._applyUndoRedoEdits(i,t,!0,!1,n,r)}_applyRedo(e,t,n,r){const i=e.map((e=>{const t=this.getPositionAt(e.oldPosition),n=this.getPositionAt(e.oldEnd);return{range:new m.Q(t.lineNumber,t.column,n.lineNumber,n.column),text:e.newText}}));this._applyUndoRedoEdits(i,t,!1,!0,n,r)}_applyUndoRedoEdits(e,t,n,r,i,s){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),this._isUndoing=n,this._isRedoing=r,this.applyEdits(e,!1),this.setEOL(t),this._overwriteAlternativeVersionId(i)}finally{this._isUndoing=!1,this._isRedoing=!1,this._eventEmitter.endDeferredEmit(s),this._onDidChangeDecorations.endDeferredEmit()}}applyEdits(e,t=!1){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit();const n=this._validateEditOperations(e);return this._doApplyEdits(n,t)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_doApplyEdits(e,t){const n=this._buffer.getLineCount(),r=this._buffer.applyEdits(e,this._options.trimAutoWhitespace,t),i=this._buffer.getLineCount(),s=r.changes;if(this._trimAutoWhitespaceLines=r.trimAutoWhitespaceLineNumbers,0!==s.length){for(let n=0,r=s.length;n=0;t--){const n=l+t,r=p+t;C.takeFromEndWhile((e=>e.lineNumber>r));const i=C.takeFromEndWhile((e=>e.lineNumber===r));e.push(new Or(n,this.getLineContent(r),i))}if(ge.lineNumbere.lineNumber===t))}e.push(new Rr(r+1,l+d,h,c))}t+=m}this._emitContentChangedEvent(new Br(e,this.getVersionId(),this._isUndoing,this._isRedoing),{changes:s,eol:this._buffer.getEOL(),isEolChange:!1,versionId:this.getVersionId(),isUndoing:this._isUndoing,isRedoing:this._isRedoing,isFlush:!1})}return null===r.reverseEdits?void 0:r.reverseEdits}undo(){return this._undoRedoService.undo(this.uri)}canUndo(){return this._undoRedoService.canUndo(this.uri)}redo(){return this._undoRedoService.redo(this.uri)}canRedo(){return this._undoRedoService.canRedo(this.uri)}handleBeforeFireDecorationsChangedEvent(e){if(null===e||0===e.size)return;const t=Array.from(e).map((e=>new Or(e,this.getLineContent(e),this._getInjectedTextInLine(e))));this._onDidChangeInjectedText.fire(new Fr(t))}changeDecorations(e,t=0){this._assertNotDisposed();try{return this._onDidChangeDecorations.beginDeferredEmit(),this._changeDecorations(t,e)}finally{this._onDidChangeDecorations.endDeferredEmit()}}_changeDecorations(e,t){const n={addDecoration:(t,n)=>this._deltaDecorationsImpl(e,[],[{range:t,options:n}])[0],changeDecoration:(e,t)=>{this._changeDecorationImpl(e,t)},changeDecorationOptions:(e,t)=>{this._changeDecorationOptionsImpl(e,ai(t))},removeDecoration:t=>{this._deltaDecorationsImpl(e,[t],[])},deltaDecorations:(t,n)=>0===t.length&&0===n.length?[]:this._deltaDecorationsImpl(e,t,n)};let r=null;try{r=t(n)}catch(i){(0,l.dz)(i)}return n.addDecoration=Gr,n.changeDecoration=Gr,n.changeDecorationOptions=Gr,n.removeDecoration=Gr,n.deltaDecorations=Gr,r}deltaDecorations(e,t,n=0){if(this._assertNotDisposed(),e||(e=[]),0===e.length&&0===t.length)return[];try{return this._deltaDecorationCallCnt++,this._deltaDecorationCallCnt>1&&(console.warn("Invoking deltaDecorations recursively could lead to leaking decorations."),(0,l.dz)(new Error("Invoking deltaDecorations recursively could lead to leaking decorations."))),this._onDidChangeDecorations.beginDeferredEmit(),this._deltaDecorationsImpl(n,e,t)}finally{this._onDidChangeDecorations.endDeferredEmit(),this._deltaDecorationCallCnt--}}_getTrackedRange(e){return this.getDecorationRange(e)}_setTrackedRange(e,t,n){const r=e?this._decorations[e]:null;if(!r)return t?this._deltaDecorationsImpl(0,[],[{range:t,options:oi[n]}],!0)[0]:null;if(!t)return this._decorationsTree.delete(r),delete this._decorations[r.id],null;const i=this._validateRangeRelaxedNoAllocations(t),s=this._buffer.getOffsetAt(i.startLineNumber,i.startColumn),o=this._buffer.getOffsetAt(i.endLineNumber,i.endColumn);return this._decorationsTree.delete(r),r.reset(this.getVersionId(),s,o,i),r.setOptions(oi[n]),this._decorationsTree.insert(r),r.id}removeAllDecorationsWithOwnerId(e){if(this._isDisposed)return;const t=this._decorationsTree.collectNodesFromOwner(e);for(let n=0,r=t.length;nthis.getLineCount()?[]:this.getLinesDecorations(e,e,t,n)}getLinesDecorations(e,t,n=0,r=!1,i=!1){const s=this.getLineCount(),a=Math.min(s,Math.max(1,e)),l=Math.min(s,Math.max(1,t)),c=this.getLineMaxColumn(l),h=new m.Q(a,1,l,c),u=this._getDecorationsInRange(h,n,r,i);return(0,o.E4)(u,this._decorationProvider.getDecorationsInRange(h,n,r)),u}getDecorationsInRange(e,t=0,n=!1,r=!1,i=!1){const s=this.validateRange(e),a=this._getDecorationsInRange(s,t,n,i);return(0,o.E4)(a,this._decorationProvider.getDecorationsInRange(s,t,n,r)),a}getOverviewRulerDecorations(e=0,t=!1){return this._decorationsTree.getAll(this,e,t,!0,!1)}getInjectedTextDecorations(e=0){return this._decorationsTree.getAllInjectedText(this,e)}_getInjectedTextInLine(e){const t=this._buffer.getOffsetAt(e,1),n=t+this._buffer.getLineLength(e),r=this._decorationsTree.getInjectedTextInInterval(this,t,n,0);return Ir.fromDecorations(r).filter((t=>t.lineNumber===e))}getAllDecorations(e=0,t=!1){let n=this._decorationsTree.getAll(this,e,t,!1,!1);return n=n.concat(this._decorationProvider.getAllDecorations(e,t)),n}getAllMarginDecorations(e=0){return this._decorationsTree.getAll(this,e,!1,!1,!0)}_getDecorationsInRange(e,t,n,r){const i=this._buffer.getOffsetAt(e.startLineNumber,e.startColumn),s=this._buffer.getOffsetAt(e.endLineNumber,e.endColumn);return this._decorationsTree.getAllInInterval(this,i,s,t,n,r)}getRangeAt(e,t){return this._buffer.getRangeAt(e,t-e)}_changeDecorationImpl(e,t){const n=this._decorations[e];if(!n)return;if(n.options.after){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.endLineNumber)}if(n.options.before){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.startLineNumber)}const r=this._validateRangeRelaxedNoAllocations(t),i=this._buffer.getOffsetAt(r.startLineNumber,r.startColumn),s=this._buffer.getOffsetAt(r.endLineNumber,r.endColumn);this._decorationsTree.delete(n),n.reset(this.getVersionId(),i,s,r),this._decorationsTree.insert(n),this._onDidChangeDecorations.checkAffectedAndFire(n.options),n.options.after&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(r.endLineNumber),n.options.before&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(r.startLineNumber)}_changeDecorationOptionsImpl(e,t){const n=this._decorations[e];if(!n)return;const r=!(!n.options.overviewRuler||!n.options.overviewRuler.color),i=!(!t.overviewRuler||!t.overviewRuler.color);if(this._onDidChangeDecorations.checkAffectedAndFire(n.options),this._onDidChangeDecorations.checkAffectedAndFire(t),n.options.after||t.after){const e=this._decorationsTree.getNodeRange(this,n);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.endLineNumber)}if(n.options.before||t.before){const e=this._decorationsTree.getNodeRange(this,n);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.startLineNumber)}const s=r!==i,o=function(e){return!!e.after||!!e.before}(t)!==Xr(n);s||o?(this._decorationsTree.delete(n),n.setOptions(t),this._decorationsTree.insert(n)):n.setOptions(t)}_deltaDecorationsImpl(e,t,n,r=!1){const i=this.getVersionId(),s=t.length;let o=0;const a=n.length;let l=0;this._onDidChangeDecorations.beginDeferredEmit();try{const c=new Array(a);for(;othis._setLanguage(e.languageId,t))),this._setLanguage(e.languageId,t))}_setLanguage(e,t){this.tokenization.setLanguageId(e,t),this._languageService.requestRichLanguageFeatures(e)}getLanguageIdAtPosition(e,t){return this.tokenization.getLanguageIdAtPosition(e,t)}getWordAtPosition(e){return this._tokenizationTextModelPart.getWordAtPosition(e)}getWordUntilPosition(e){return this._tokenizationTextModelPart.getWordUntilPosition(e)}normalizePosition(e,t){return e}getLineIndentColumn(e){return function(e){let t=0;for(const n of e){if(" "!==n&&"\t"!==n)break;t++}return t}(this.getLineContent(e))+1}};function Jr(e){return!(!e.options.overviewRuler||!e.options.overviewRuler.color)}function Xr(e){return!!e.options.after||!!e.options.before}Qr=qr=Wr([Ur(4,Vr),Ur(5,k.L),Ur(6,se),Ur(7,H._Y)],Qr);class Yr{constructor(){this._decorationsTree0=new un,this._decorationsTree1=new un,this._injectedTextDecorationsTree=new un}ensureAllNodesHaveRanges(e){this.getAll(e,0,!1,!1,!1)}_ensureNodesHaveRanges(e,t){for(const n of t)null===n.range&&(n.range=e.getRangeAt(n.cachedAbsoluteStart,n.cachedAbsoluteEnd));return t}getAllInInterval(e,t,n,r,i,s){const o=e.getVersionId(),a=this._intervalSearch(t,n,r,i,o,s);return this._ensureNodesHaveRanges(e,a)}_intervalSearch(e,t,n,r,i,s){const o=this._decorationsTree0.intervalSearch(e,t,n,r,i,s),a=this._decorationsTree1.intervalSearch(e,t,n,r,i,s),l=this._injectedTextDecorationsTree.intervalSearch(e,t,n,r,i,s);return o.concat(a).concat(l)}getInjectedTextInInterval(e,t,n,r){const i=e.getVersionId(),s=this._injectedTextDecorationsTree.intervalSearch(t,n,r,!1,i,!1);return this._ensureNodesHaveRanges(e,s).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAllInjectedText(e,t){const n=e.getVersionId(),r=this._injectedTextDecorationsTree.search(t,!1,n,!1);return this._ensureNodesHaveRanges(e,r).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAll(e,t,n,r,i){const s=e.getVersionId(),o=this._search(t,n,r,s,i);return this._ensureNodesHaveRanges(e,o)}_search(e,t,n,r,i){if(n)return this._decorationsTree1.search(e,t,r,i);{const n=this._decorationsTree0.search(e,t,r,i),s=this._decorationsTree1.search(e,t,r,i),o=this._injectedTextDecorationsTree.search(e,t,r,i);return n.concat(s).concat(o)}}collectNodesFromOwner(e){const t=this._decorationsTree0.collectNodesFromOwner(e),n=this._decorationsTree1.collectNodesFromOwner(e),r=this._injectedTextDecorationsTree.collectNodesFromOwner(e);return t.concat(n).concat(r)}collectNodesPostOrder(){const e=this._decorationsTree0.collectNodesPostOrder(),t=this._decorationsTree1.collectNodesPostOrder(),n=this._injectedTextDecorationsTree.collectNodesPostOrder();return e.concat(t).concat(n)}insert(e){Xr(e)?this._injectedTextDecorationsTree.insert(e):Jr(e)?this._decorationsTree1.insert(e):this._decorationsTree0.insert(e)}delete(e){Xr(e)?this._injectedTextDecorationsTree.delete(e):Jr(e)?this._decorationsTree1.delete(e):this._decorationsTree0.delete(e)}getNodeRange(e,t){const n=e.getVersionId();return t.cachedVersionId!==n&&this._resolveNode(t,n),null===t.range&&(t.range=e.getRangeAt(t.cachedAbsoluteStart,t.cachedAbsoluteEnd)),t.range}_resolveNode(e,t){Xr(e)?this._injectedTextDecorationsTree.resolveNode(e,t):Jr(e)?this._decorationsTree1.resolveNode(e,t):this._decorationsTree0.resolveNode(e,t)}acceptReplace(e,t,n,r){this._decorationsTree0.acceptReplace(e,t,n,r),this._decorationsTree1.acceptReplace(e,t,n,r),this._injectedTextDecorationsTree.acceptReplace(e,t,n,r)}}function Zr(e){return e.replace(/[^a-z0-9\-_]/gi," ")}class ei{constructor(e){this.color=e.color||"",this.darkColor=e.darkColor||""}}class ti extends ei{constructor(e){super(e),this._resolvedColor=null,this.position="number"===typeof e.position?e.position:me.A5.Center}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=null}_resolveColor(e,t){if("string"===typeof e)return e;const n=e?t.getColor(e.id):null;return n?n.toString():""}}class ni{constructor(e){this.position=e?.position??me.ZS.Center,this.persistLane=e?.persistLane}}class ri extends ei{constructor(e){super(e),this.position=e.position,this.sectionHeaderStyle=e.sectionHeaderStyle??null,this.sectionHeaderText=e.sectionHeaderText??null}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=void 0}_resolveColor(e,t){return"string"===typeof e?a.Q1.fromHex(e):t.getColor(e.id)}}class ii{static from(e){return e instanceof ii?e:new ii(e)}constructor(e){this.content=e.content||"",this.inlineClassName=e.inlineClassName||null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.attachedData=e.attachedData||null,this.cursorStops=e.cursorStops||null}}class si{static register(e){return new si(e)}static createDynamic(e){return new si(e)}constructor(e){this.description=e.description,this.blockClassName=e.blockClassName?Zr(e.blockClassName):null,this.blockDoesNotCollapse=e.blockDoesNotCollapse??null,this.blockIsAfterEnd=e.blockIsAfterEnd??null,this.blockPadding=e.blockPadding??null,this.stickiness=e.stickiness||0,this.zIndex=e.zIndex||0,this.className=e.className?Zr(e.className):null,this.shouldFillLineOnLineBreak=e.shouldFillLineOnLineBreak??null,this.hoverMessage=e.hoverMessage||null,this.glyphMarginHoverMessage=e.glyphMarginHoverMessage||null,this.lineNumberHoverMessage=e.lineNumberHoverMessage||null,this.isWholeLine=e.isWholeLine||!1,this.showIfCollapsed=e.showIfCollapsed||!1,this.collapseOnReplaceEdit=e.collapseOnReplaceEdit||!1,this.overviewRuler=e.overviewRuler?new ti(e.overviewRuler):null,this.minimap=e.minimap?new ri(e.minimap):null,this.glyphMargin=e.glyphMarginClassName?new ni(e.glyphMargin):null,this.glyphMarginClassName=e.glyphMarginClassName?Zr(e.glyphMarginClassName):null,this.linesDecorationsClassName=e.linesDecorationsClassName?Zr(e.linesDecorationsClassName):null,this.lineNumberClassName=e.lineNumberClassName?Zr(e.lineNumberClassName):null,this.linesDecorationsTooltip=e.linesDecorationsTooltip?c.jy(e.linesDecorationsTooltip):null,this.firstLineDecorationClassName=e.firstLineDecorationClassName?Zr(e.firstLineDecorationClassName):null,this.marginClassName=e.marginClassName?Zr(e.marginClassName):null,this.inlineClassName=e.inlineClassName?Zr(e.inlineClassName):null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.beforeContentClassName=e.beforeContentClassName?Zr(e.beforeContentClassName):null,this.afterContentClassName=e.afterContentClassName?Zr(e.afterContentClassName):null,this.after=e.after?ii.from(e.after):null,this.before=e.before?ii.from(e.before):null,this.hideInCommentTokens=e.hideInCommentTokens??!1,this.hideInStringTokens=e.hideInStringTokens??!1}}si.EMPTY=si.register({description:"empty"});const oi=[si.register({description:"tracked-range-always-grows-when-typing-at-edges",stickiness:0}),si.register({description:"tracked-range-never-grows-when-typing-at-edges",stickiness:1}),si.register({description:"tracked-range-grows-only-when-typing-before",stickiness:2}),si.register({description:"tracked-range-grows-only-when-typing-after",stickiness:3})];function ai(e){return e instanceof si?e:si.createDynamic(e)}class li extends i.jG{constructor(e){super(),this.handleBeforeFire=e,this._actual=this._register(new r.vl),this.event=this._actual.event,this._affectedInjectedTextLines=null,this._deferredCnt=0,this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._affectsLineNumber=!1}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(){this._deferredCnt--,0===this._deferredCnt&&(this._shouldFireDeferred&&this.doFire(),this._affectedInjectedTextLines?.clear(),this._affectedInjectedTextLines=null)}recordLineAffectedByInjectedText(e){this._affectedInjectedTextLines||(this._affectedInjectedTextLines=new Set),this._affectedInjectedTextLines.add(e)}checkAffectedAndFire(e){this._affectsMinimap||=!!e.minimap?.position,this._affectsOverviewRuler||=!!e.overviewRuler?.color,this._affectsGlyphMargin||=!!e.glyphMarginClassName,this._affectsLineNumber||=!!e.lineNumberClassName,this.tryFire()}fire(){this._affectsMinimap=!0,this._affectsOverviewRuler=!0,this._affectsGlyphMargin=!0,this.tryFire()}tryFire(){0===this._deferredCnt?this.doFire():this._shouldFireDeferred=!0}doFire(){this.handleBeforeFire(this._affectedInjectedTextLines);const e={affectsMinimap:this._affectsMinimap,affectsOverviewRuler:this._affectsOverviewRuler,affectsGlyphMargin:this._affectsGlyphMargin,affectsLineNumber:this._affectsLineNumber};this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._actual.fire(e)}}class ci extends i.jG{constructor(){super(),this._fastEmitter=this._register(new r.vl),this.fastEvent=this._fastEmitter.event,this._slowEmitter=this._register(new r.vl),this.slowEvent=this._slowEmitter.event,this._deferredCnt=0,this._deferredEvent=null}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(e=null){if(this._deferredCnt--,0===this._deferredCnt&&null!==this._deferredEvent){this._deferredEvent.rawContentChangedEvent.resultingSelection=e;const t=this._deferredEvent;this._deferredEvent=null,this._fastEmitter.fire(t),this._slowEmitter.fire(t)}}fire(e){this._deferredCnt>0?this._deferredEvent?this._deferredEvent=this._deferredEvent.merge(e):this._deferredEvent=e:(this._fastEmitter.fire(e),this._slowEmitter.fire(e))}}var hi,ui=n(360),di=n(5600),gi=n(6456),fi=n(146),mi=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},pi=function(e,t){return function(n,r){t(n,r,e)}};function bi(e){return e.toString()}class _i{constructor(e,t,n){this.model=e,this._modelEventListeners=new i.Cm,this.model=e,this._modelEventListeners.add(e.onWillDispose((()=>t(e)))),this._modelEventListeners.add(e.onDidChangeLanguage((t=>n(e,t))))}dispose(){this._modelEventListeners.dispose()}}const ki=s.j9||s.zx?1:2;class vi{constructor(e,t,n,r,i,s,o,a){this.uri=e,this.initialUndoRedoSnapshot=t,this.time=n,this.sharesUndoRedoStack=r,this.heapSize=i,this.sha1=s,this.versionId=o,this.alternativeVersionId=a}}let Ci=class extends i.jG{static{hi=this}static{this.MAX_MEMORY_FOR_CLOSED_FILES_UNDO_STACK=20971520}constructor(e,t,n,i){super(),this._configurationService=e,this._resourcePropertiesService=t,this._undoRedoService=n,this._instantiationService=i,this._onModelAdded=this._register(new r.vl),this.onModelAdded=this._onModelAdded.event,this._onModelRemoved=this._register(new r.vl),this.onModelRemoved=this._onModelRemoved.event,this._onModelModeChanged=this._register(new r.vl),this.onModelLanguageChanged=this._onModelModeChanged.event,this._modelCreationOptionsByLanguageAndResource=Object.create(null),this._models={},this._disposedModels=new Map,this._disposedModelsHeapSize=0,this._register(this._configurationService.onDidChangeConfiguration((e=>this._updateModelOptions(e)))),this._updateModelOptions(void 0)}static _readModelOptions(e,t){let n=b.tabSize;if(e.editor&&"undefined"!==typeof e.editor.tabSize){const t=parseInt(e.editor.tabSize,10);isNaN(t)||(n=t),n<1&&(n=1)}let r="tabSize";if(e.editor&&"undefined"!==typeof e.editor.indentSize&&"tabSize"!==e.editor.indentSize){const t=parseInt(e.editor.indentSize,10);isNaN(t)||(r=Math.max(t,1))}let i=b.insertSpaces;e.editor&&"undefined"!==typeof e.editor.insertSpaces&&(i="false"!==e.editor.insertSpaces&&Boolean(e.editor.insertSpaces));let s=ki;const o=e.eol;"\r\n"===o?s=2:"\n"===o&&(s=1);let a=b.trimAutoWhitespace;e.editor&&"undefined"!==typeof e.editor.trimAutoWhitespace&&(a="false"!==e.editor.trimAutoWhitespace&&Boolean(e.editor.trimAutoWhitespace));let l=b.detectIndentation;e.editor&&"undefined"!==typeof e.editor.detectIndentation&&(l="false"!==e.editor.detectIndentation&&Boolean(e.editor.detectIndentation));let c=b.largeFileOptimizations;e.editor&&"undefined"!==typeof e.editor.largeFileOptimizations&&(c="false"!==e.editor.largeFileOptimizations&&Boolean(e.editor.largeFileOptimizations));let h=b.bracketPairColorizationOptions;return e.editor?.bracketPairColorization&&"object"===typeof e.editor.bracketPairColorization&&(h={enabled:!!e.editor.bracketPairColorization.enabled,independentColorPoolPerBracketType:!!e.editor.bracketPairColorization.independentColorPoolPerBracketType}),{isForSimpleWidget:t,tabSize:n,indentSize:r,insertSpaces:i,detectIndentation:l,defaultEOL:s,trimAutoWhitespace:a,largeFileOptimizations:c,bracketPairColorizationOptions:h}}_getEOL(e,t){if(e)return this._resourcePropertiesService.getEOL(e,t);const n=this._configurationService.getValue("files.eol",{overrideIdentifier:t});return n&&"string"===typeof n&&"auto"!==n?n:3===s.OS||2===s.OS?"\n":"\r\n"}_shouldRestoreUndoStack(){const e=this._configurationService.getValue("files.restoreUndoStack");return"boolean"!==typeof e||e}getCreationOptions(e,t,n){const r="string"===typeof e?e:e.languageId;let i=this._modelCreationOptionsByLanguageAndResource[r+t];if(!i){const e=this._configurationService.getValue("editor",{overrideIdentifier:r,resource:t}),s=this._getEOL(t,r);i=hi._readModelOptions({editor:e,eol:s},n),this._modelCreationOptionsByLanguageAndResource[r+t]=i}return i}_updateModelOptions(e){const t=this._modelCreationOptionsByLanguageAndResource;this._modelCreationOptionsByLanguageAndResource=Object.create(null);const n=Object.keys(this._models);for(let r=0,i=n.length;re){const t=[];for(this._disposedModels.forEach((e=>{e.sharesUndoRedoStack||t.push(e)})),t.sort(((e,t)=>e.time-t.time));t.length>0&&this._disposedModelsHeapSize>e;){const e=t.shift();this._removeDisposedModel(e.uri),null!==e.initialUndoRedoSnapshot&&this._undoRedoService.restoreSnapshot(e.initialUndoRedoSnapshot)}}}_createModelData(e,t,n,r){const i=this.getCreationOptions(t,n,r),s=this._instantiationService.createInstance(Qr,e,t,i,n);if(n&&this._disposedModels.has(bi(n))){const e=this._removeDisposedModel(n),t=this._undoRedoService.getElements(n),r=this._getSHA1Computer(),i=!!r.canComputeSHA1(s)&&r.computeSHA1(s)===e.sha1;if(i||e.sharesUndoRedoStack){for(const e of t.past)zt(e)&&e.matchesResource(n)&&e.setModel(s);for(const e of t.future)zt(e)&&e.matchesResource(n)&&e.setModel(s);this._undoRedoService.setElementsValidFlag(n,!0,(e=>zt(e)&&e.matchesResource(n))),i&&(s._overwriteVersionId(e.versionId),s._overwriteAlternativeVersionId(e.alternativeVersionId),s._overwriteInitialUndoRedoSnapshot(e.initialUndoRedoSnapshot))}else null!==e.initialUndoRedoSnapshot&&this._undoRedoService.restoreSnapshot(e.initialUndoRedoSnapshot)}const o=bi(s.uri);if(this._models[o])throw new Error("ModelService: Cannot add model because it already exists!");const a=new _i(s,(e=>this._onWillDispose(e)),((e,t)=>this._onDidChangeLanguage(e,t)));return this._models[o]=a,a}createModel(e,t,n,r=!1){let i;return i=t?this._createModelData(e,t,n,r):this._createModelData(e,Q.vH,n,r),this._onModelAdded.fire(i.model),i.model}getModels(){const e=[],t=Object.keys(this._models);for(let n=0,r=t.length;n0||t.future.length>0){for(const n of t.past)zt(n)&&n.matchesResource(e.uri)&&(i=!0,s+=n.heapSize(e.uri),n.setModel(e.uri));for(const n of t.future)zt(n)&&n.matchesResource(e.uri)&&(i=!0,s+=n.heapSize(e.uri),n.setModel(e.uri))}}const o=hi.MAX_MEMORY_FOR_CLOSED_FILES_UNDO_STACK,a=this._getSHA1Computer();if(i)if(r||!(s>o)&&a.canComputeSHA1(e))this._ensureDisposedModelsHeapSize(o-s),this._undoRedoService.setElementsValidFlag(e.uri,!1,(t=>zt(t)&&t.matchesResource(e.uri))),this._insertDisposedModel(new vi(e.uri,n.model.getInitialUndoRedoSnapshot(),Date.now(),r,s,a.computeSHA1(e),e.getVersionId(),e.getAlternativeVersionId()));else{const e=n.model.getInitialUndoRedoSnapshot();null!==e&&this._undoRedoService.restoreSnapshot(e)}else if(!r){const e=n.model.getInitialUndoRedoSnapshot();null!==e&&this._undoRedoService.restoreSnapshot(e)}delete this._models[t],n.dispose(),delete this._modelCreationOptionsByLanguageAndResource[e.getLanguageId()+e.uri],this._onModelRemoved.fire(e)}_onDidChangeLanguage(e,t){const n=t.oldLanguage,r=e.getLanguageId(),i=this.getCreationOptions(n,e.uri,e.isForSimpleWidget),s=this.getCreationOptions(r,e.uri,e.isForSimpleWidget);hi._setModelOptionsForModel(e,s,i),this._onModelModeChanged.fire({model:e,oldLanguageId:n})}_getSHA1Computer(){return new yi}};Ci=hi=mi([pi(0,K.pG),pi(1,ui.ITextResourcePropertiesService),pi(2,Vr),pi(3,H._Y)],Ci);class yi{static{this.MAX_MODEL_SIZE=10485760}canComputeSHA1(e){return e.getValueLength()<=yi.MAX_MODEL_SIZE}computeSHA1(e){const t=new di.v7,n=e.createSnapshot();let r;for(;r=n.read();)t.update(r);return t.digest()}}},1788:(e,t,n)=>{"use strict";function r(e){return e}n.d(t,{VV:()=>s,o5:()=>i});class i{constructor(e,t){this.lastCache=void 0,this.lastArgKey=void 0,"function"===typeof e?(this._fn=e,this._computeKey=r):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);return this.lastArgKey!==t&&(this.lastArgKey=t,this.lastCache=this._fn(e)),this.lastCache}}class s{get cachedValues(){return this._map}constructor(e,t){this._map=new Map,this._map2=new Map,"function"===typeof e?(this._fn=e,this._computeKey=r):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);if(this._map2.has(t))return this._map2.get(t);const n=this._fn(e);return this._map.set(e,n),this._map2.set(t,n),n}}},1929:(e,t,n)=>{"use strict";n.r(t),n.d(t,{SimpleWorkerClient:()=>k,SimpleWorkerServer:()=>y,create:()=>L,logOnceWebWorkerWarning:()=>d});var r=n(4383),i=n(1234),s=n(1484),o=n(6456),a=n(8067),l=n(1508);const c="default",h="$initialize";let u=!1;function d(e){a.HZ&&(u||(u=!0,console.warn("Could not create web worker(s). Falling back to loading web worker code in main thread, which might cause UI freezes. Please see https://github.com/microsoft/monaco-editor#faq")),console.warn(e.message))}class g{constructor(e,t,n,r,i){this.vsWorker=e,this.req=t,this.channel=n,this.method=r,this.args=i,this.type=0}}class f{constructor(e,t,n,r){this.vsWorker=e,this.seq=t,this.res=n,this.err=r,this.type=1}}class m{constructor(e,t,n,r,i){this.vsWorker=e,this.req=t,this.channel=n,this.eventName=r,this.arg=i,this.type=2}}class p{constructor(e,t,n){this.vsWorker=e,this.req=t,this.event=n,this.type=3}}class b{constructor(e,t){this.vsWorker=e,this.req=t,this.type=4}}class _{constructor(e){this._workerId=-1,this._handler=e,this._lastSentReq=0,this._pendingReplies=Object.create(null),this._pendingEmitters=new Map,this._pendingEvents=new Map}setWorkerId(e){this._workerId=e}sendMessage(e,t,n){const r=String(++this._lastSentReq);return new Promise(((i,s)=>{this._pendingReplies[r]={resolve:i,reject:s},this._send(new g(this._workerId,r,e,t,n))}))}listen(e,t,n){let r=null;const s=new i.vl({onWillAddFirstListener:()=>{r=String(++this._lastSentReq),this._pendingEmitters.set(r,s),this._send(new m(this._workerId,r,e,t,n))},onDidRemoveLastListener:()=>{this._pendingEmitters.delete(r),this._send(new b(this._workerId,r)),r=null}});return s.event}handleMessage(e){e&&e.vsWorker&&(-1!==this._workerId&&e.vsWorker!==this._workerId||this._handleMessage(e))}createProxyToRemoteChannel(e,t){const n={get:(n,r)=>("string"!==typeof r||n[r]||(C(r)?n[r]=t=>this.listen(e,r,t):v(r)?n[r]=this.listen(e,r,void 0):36===r.charCodeAt(0)&&(n[r]=async(...n)=>(await(t?.()),this.sendMessage(e,r,n)))),n[r])};return new Proxy(Object.create(null),n)}_handleMessage(e){switch(e.type){case 1:return this._handleReplyMessage(e);case 0:return this._handleRequestMessage(e);case 2:return this._handleSubscribeEventMessage(e);case 3:return this._handleEventMessage(e);case 4:return this._handleUnsubscribeEventMessage(e)}}_handleReplyMessage(e){if(!this._pendingReplies[e.seq])return void console.warn("Got reply to unknown seq");const t=this._pendingReplies[e.seq];if(delete this._pendingReplies[e.seq],e.err){let n=e.err;return e.err.$isError&&(n=new Error,n.name=e.err.name,n.message=e.err.message,n.stack=e.err.stack),void t.reject(n)}t.resolve(e.res)}_handleRequestMessage(e){const t=e.req;this._handler.handleMessage(e.channel,e.method,e.args).then((e=>{this._send(new f(this._workerId,t,e,void 0))}),(e=>{e.detail instanceof Error&&(e.detail=(0,r.cU)(e.detail)),this._send(new f(this._workerId,t,void 0,(0,r.cU)(e)))}))}_handleSubscribeEventMessage(e){const t=e.req,n=this._handler.handleEvent(e.channel,e.eventName,e.arg)((e=>{this._send(new p(this._workerId,t,e))}));this._pendingEvents.set(t,n)}_handleEventMessage(e){this._pendingEmitters.has(e.req)?this._pendingEmitters.get(e.req).fire(e.event):console.warn("Got event for unknown req")}_handleUnsubscribeEventMessage(e){this._pendingEvents.has(e.req)?(this._pendingEvents.get(e.req).dispose(),this._pendingEvents.delete(e.req)):console.warn("Got unsubscribe for unknown req")}_send(e){const t=[];if(0===e.type)for(let n=0;n{this._protocol.handleMessage(e)}),(e=>{(0,r.dz)(e)}))),this._protocol=new _({sendMessage:(e,t)=>{this._worker.postMessage(e,t)},handleMessage:(e,t,n)=>this._handleMessage(e,t,n),handleEvent:(e,t,n)=>this._handleEvent(e,t,n)}),this._protocol.setWorkerId(this._worker.getId());let n=null;const i=globalThis.require;"undefined"!==typeof i&&"function"===typeof i.getConfig?n=i.getConfig():"undefined"!==typeof globalThis.requirejs&&(n=globalThis.requirejs.s.contexts._.config),this._onModuleLoaded=this._protocol.sendMessage(c,h,[this._worker.getId(),JSON.parse(JSON.stringify(n)),t.amdModuleId]),this.proxy=this._protocol.createProxyToRemoteChannel(c,(async()=>{await this._onModuleLoaded})),this._onModuleLoaded.catch((e=>{this._onError("Worker failed to load "+t.amdModuleId,e)}))}_handleMessage(e,t,n){const r=this._localChannels.get(e);if(!r)return Promise.reject(new Error(`Missing channel ${e} on main thread`));if("function"!==typeof r[t])return Promise.reject(new Error(`Missing method ${t} on main thread channel ${e}`));try{return Promise.resolve(r[t].apply(r,n))}catch(i){return Promise.reject(i)}}_handleEvent(e,t,n){const r=this._localChannels.get(e);if(!r)throw new Error(`Missing channel ${e} on main thread`);if(C(t)){const i=r[t].call(r,n);if("function"!==typeof i)throw new Error(`Missing dynamic event ${t} on main thread channel ${e}.`);return i}if(v(t)){const n=r[t];if("function"!==typeof n)throw new Error(`Missing event ${t} on main thread channel ${e}.`);return n}throw new Error(`Malformed event name ${t}`)}setChannel(e,t){this._localChannels.set(e,t)}_onError(e,t){console.error(e),console.info(t)}}function v(e){return"o"===e[0]&&"n"===e[1]&&l.Wv(e.charCodeAt(2))}function C(e){return/^onDynamic/.test(e)&&l.Wv(e.charCodeAt(9))}class y{constructor(e,t){this._localChannels=new Map,this._remoteChannels=new Map,this._requestHandlerFactory=t,this._requestHandler=null,this._protocol=new _({sendMessage:(t,n)=>{e(t,n)},handleMessage:(e,t,n)=>this._handleMessage(e,t,n),handleEvent:(e,t,n)=>this._handleEvent(e,t,n)})}onmessage(e){this._protocol.handleMessage(e)}_handleMessage(e,t,n){if(e===c&&t===h)return this.initialize(n[0],n[1],n[2]);const r=e===c?this._requestHandler:this._localChannels.get(e);if(!r)return Promise.reject(new Error(`Missing channel ${e} on worker thread`));if("function"!==typeof r[t])return Promise.reject(new Error(`Missing method ${t} on worker thread channel ${e}`));try{return Promise.resolve(r[t].apply(r,n))}catch(i){return Promise.reject(i)}}_handleEvent(e,t,n){const r=e===c?this._requestHandler:this._localChannels.get(e);if(!r)throw new Error(`Missing channel ${e} on worker thread`);if(C(t)){const e=r[t].call(r,n);if("function"!==typeof e)throw new Error(`Missing dynamic event ${t} on request handler.`);return e}if(v(t)){const e=r[t];if("function"!==typeof e)throw new Error(`Missing event ${t} on request handler.`);return e}throw new Error(`Malformed event name ${t}`)}getChannel(e){if(!this._remoteChannels.has(e)){const t=this._protocol.createProxyToRemoteChannel(e);this._remoteChannels.set(e,t)}return this._remoteChannels.get(e)}async initialize(e,t,r){if(this._protocol.setWorkerId(e),!this._requestHandlerFactory){t&&("undefined"!==typeof t.baseUrl&&delete t.baseUrl,"undefined"!==typeof t.paths&&"undefined"!==typeof t.paths.vs&&delete t.paths.vs,"undefined"!==typeof t.trustedTypesPolicy&&delete t.trustedTypesPolicy,t.catchError=!0,globalThis.require.config(t));{const e=o.zl.asBrowserUri(`${r}.js`).toString(!0);return n(5890)(`${e}`).then((e=>{if(this._requestHandler=e.create(this),!this._requestHandler)throw new Error("No RequestHandler!")}))}}this._requestHandler=this._requestHandlerFactory(this)}}function L(e){return new y(e,null)}},1939:(e,t,n)=>{"use strict";n.d(t,{K:()=>r});const r=Object.freeze({text:"text/plain",binary:"application/octet-stream",unknown:"application/unknown",markdown:"text/markdown",latex:"text/latex",uriList:"text/uri-list"})},1940:(e,t,n)=>{"use strict";n.d(t,{vb:()=>l,uC:()=>c,Qg:()=>a,$6:()=>h});n(8447);var r=n(4383),i=n(1234),s=n(1484),o=n(8067);Symbol("MicrotaskDelay");function a(e){return!!e&&"function"===typeof e.then}class l{constructor(){this.disposable=void 0,this.isDisposed=!1}cancel(){this.disposable?.dispose(),this.disposable=void 0}cancelAndSet(e,t,n=globalThis){if(this.isDisposed)throw new r.D7("Calling 'cancelAndSet' on a disposed IntervalTimer");this.cancel();const i=n.setInterval((()=>{e()}),t);this.disposable=(0,s.s)((()=>{n.clearInterval(i),this.disposable=void 0}))}dispose(){this.cancel(),this.isDisposed=!0}}class c{constructor(e,t){this.timeoutToken=-1,this.runner=e,this.timeout=t,this.timeoutHandler=this.onTimeout.bind(this)}dispose(){this.cancel(),this.runner=null}cancel(){this.isScheduled()&&(clearTimeout(this.timeoutToken),this.timeoutToken=-1)}schedule(e=this.timeout){this.cancel(),this.timeoutToken=setTimeout(this.timeoutHandler,e)}get delay(){return this.timeout}set delay(e){this.timeout=e}isScheduled(){return-1!==this.timeoutToken}onTimeout(){this.timeoutToken=-1,this.runner&&this.doRun()}doRun(){this.runner?.()}}let h,u;u="function"!==typeof globalThis.requestIdleCallback||"function"!==typeof globalThis.cancelIdleCallback?(e,t)=>{(0,o._p)((()=>{if(n)return;const e=Date.now()+15,r={didTimeout:!0,timeRemaining:()=>Math.max(0,e-Date.now())};t(Object.freeze(r))}));let n=!1;return{dispose(){n||(n=!0)}}}:(e,t,n)=>{const r=e.requestIdleCallback(t,"number"===typeof n?{timeout:n}:void 0);let i=!1;return{dispose(){i||(i=!0,e.cancelIdleCallback(r))}}},h=e=>u(globalThis,e);var d;!function(e){e.settled=async function(e){let t;const n=await Promise.all(e.map((e=>e.then((e=>e),(e=>{t||(t=e)})))));if("undefined"!==typeof t)throw t;return n},e.withAsyncBody=function(e){return new Promise((async(t,n)=>{try{await e(t,n)}catch(r){n(r)}}))}}(d||(d={}));class g{static fromArray(e){return new g((t=>{t.emitMany(e)}))}static fromPromise(e){return new g((async t=>{t.emitMany(await e)}))}static fromPromises(e){return new g((async t=>{await Promise.all(e.map((async e=>t.emitOne(await e))))}))}static merge(e){return new g((async t=>{await Promise.all(e.map((async e=>{for await(const n of e)t.emitOne(n)})))}))}static{this.EMPTY=g.fromArray([])}constructor(e,t){this._state=0,this._results=[],this._error=null,this._onReturn=t,this._onStateChanged=new i.vl,queueMicrotask((async()=>{const t={emitOne:e=>this.emitOne(e),emitMany:e=>this.emitMany(e),reject:e=>this.reject(e)};try{await Promise.resolve(e(t)),this.resolve()}catch(n){this.reject(n)}finally{t.emitOne=void 0,t.emitMany=void 0,t.reject=void 0}}))}[Symbol.asyncIterator](){let e=0;return{next:async()=>{for(;;){if(2===this._state)throw this._error;if(e(this._onReturn?.(),{done:!0,value:void 0})}}static map(e,t){return new g((async n=>{for await(const r of e)n.emitOne(t(r))}))}map(e){return g.map(this,e)}static filter(e,t){return new g((async n=>{for await(const r of e)t(r)&&n.emitOne(r)}))}filter(e){return g.filter(this,e)}static coalesce(e){return g.filter(e,(e=>!!e))}coalesce(){return g.coalesce(this)}static async toPromise(e){const t=[];for await(const n of e)t.push(n);return t}toPromise(){return g.toPromise(this)}emitOne(e){0===this._state&&(this._results.push(e),this._onStateChanged.fire())}emitMany(e){0===this._state&&(this._results=this._results.concat(e),this._onStateChanged.fire())}resolve(){0===this._state&&(this._state=1,this._onStateChanged.fire())}reject(e){0===this._state&&(this._state=2,this._error=e,this._onStateChanged.fire())}}},2083:(e,t,n)=>{"use strict";n.d(t,{rY:()=>p,ou:()=>m,dG:()=>L,OB:()=>w});var r=n(9493),i=(n(9400),n(1234)),s=n(1484);class o{constructor(){this._tokenizationSupports=new Map,this._factories=new Map,this._onDidChange=new i.vl,this.onDidChange=this._onDidChange.event,this._colorMap=null}handleChange(e){this._onDidChange.fire({changedLanguages:e,changedColorMap:!1})}register(e,t){return this._tokenizationSupports.set(e,t),this.handleChange([e]),(0,s.s)((()=>{this._tokenizationSupports.get(e)===t&&(this._tokenizationSupports.delete(e),this.handleChange([e]))}))}get(e){return this._tokenizationSupports.get(e)||null}registerFactory(e,t){this._factories.get(e)?.dispose();const n=new a(this,e,t);return this._factories.set(e,n),(0,s.s)((()=>{const t=this._factories.get(e);t&&t===n&&(this._factories.delete(e),t.dispose())}))}async getOrCreate(e){const t=this.get(e);if(t)return t;const n=this._factories.get(e);return!n||n.isResolved?null:(await n.resolve(),this.get(e))}isResolved(e){if(this.get(e))return!0;const t=this._factories.get(e);return!(t&&!t.isResolved)}setColorMap(e){this._colorMap=e,this._onDidChange.fire({changedLanguages:Array.from(this._tokenizationSupports.keys()),changedColorMap:!0})}getColorMap(){return this._colorMap}getDefaultBackground(){return this._colorMap&&this._colorMap.length>2?this._colorMap[2]:null}}class a extends s.jG{get isResolved(){return this._isResolved}constructor(e,t,n){super(),this._registry=e,this._languageId=t,this._factory=n,this._isDisposed=!1,this._resolvePromise=null,this._isResolved=!1}dispose(){this._isDisposed=!0,super.dispose()}async resolve(){return this._resolvePromise||(this._resolvePromise=this._create()),this._resolvePromise}async _create(){const e=await this._factory.tokenizationSupport;this._isResolved=!0,e&&!this._isDisposed&&this._register(this._registry.register(this._languageId,e))}}var l,c,h,u,d,g,f=n(8209);class m{constructor(e,t,n){this.offset=e,this.type=t,this.language=n,this._tokenBrand=void 0}toString(){return"("+this.offset+", "+this.type+")"}}class p{constructor(e,t){this.tokens=e,this.endState=t,this._encodedTokenizationResultBrand=void 0}}!function(e){e[e.Increase=0]="Increase",e[e.Decrease=1]="Decrease"}(l||(l={})),function(e){const t=new Map;t.set(0,r.W.symbolMethod),t.set(1,r.W.symbolFunction),t.set(2,r.W.symbolConstructor),t.set(3,r.W.symbolField),t.set(4,r.W.symbolVariable),t.set(5,r.W.symbolClass),t.set(6,r.W.symbolStruct),t.set(7,r.W.symbolInterface),t.set(8,r.W.symbolModule),t.set(9,r.W.symbolProperty),t.set(10,r.W.symbolEvent),t.set(11,r.W.symbolOperator),t.set(12,r.W.symbolUnit),t.set(13,r.W.symbolValue),t.set(15,r.W.symbolEnum),t.set(14,r.W.symbolConstant),t.set(15,r.W.symbolEnum),t.set(16,r.W.symbolEnumMember),t.set(17,r.W.symbolKeyword),t.set(27,r.W.symbolSnippet),t.set(18,r.W.symbolText),t.set(19,r.W.symbolColor),t.set(20,r.W.symbolFile),t.set(21,r.W.symbolReference),t.set(22,r.W.symbolCustomColor),t.set(23,r.W.symbolFolder),t.set(24,r.W.symbolTypeParameter),t.set(25,r.W.account),t.set(26,r.W.issues),e.toIcon=function(e){let n=t.get(e);return n||(console.info("No codicon found for CompletionItemKind "+e),n=r.W.symbolProperty),n};const n=new Map;n.set("method",0),n.set("function",1),n.set("constructor",2),n.set("field",3),n.set("variable",4),n.set("class",5),n.set("struct",6),n.set("interface",7),n.set("module",8),n.set("property",9),n.set("event",10),n.set("operator",11),n.set("unit",12),n.set("value",13),n.set("constant",14),n.set("enum",15),n.set("enum-member",16),n.set("enumMember",16),n.set("keyword",17),n.set("snippet",27),n.set("text",18),n.set("color",19),n.set("file",20),n.set("reference",21),n.set("customcolor",22),n.set("folder",23),n.set("type-parameter",24),n.set("typeParameter",24),n.set("account",25),n.set("issue",26),e.fromString=function(e,t){let r=n.get(e);return"undefined"!==typeof r||t||(r=9),r}}(c||(c={})),function(e){e[e.Automatic=0]="Automatic",e[e.Explicit=1]="Explicit"}(h||(h={}));!function(e){e[e.Automatic=0]="Automatic",e[e.PasteAs=1]="PasteAs"}(u||(u={})),function(e){e[e.Invoke=1]="Invoke",e[e.TriggerCharacter=2]="TriggerCharacter",e[e.ContentChange=3]="ContentChange"}(d||(d={})),function(e){e[e.Text=0]="Text",e[e.Read=1]="Read",e[e.Write=2]="Write"}(g||(g={}));(0,f.kg)("Array","array"),(0,f.kg)("Boolean","boolean"),(0,f.kg)("Class","class"),(0,f.kg)("Constant","constant"),(0,f.kg)("Constructor","constructor"),(0,f.kg)("Enum","enumeration"),(0,f.kg)("EnumMember","enumeration member"),(0,f.kg)("Event","event"),(0,f.kg)("Field","field"),(0,f.kg)("File","file"),(0,f.kg)("Function","function"),(0,f.kg)("Interface","interface"),(0,f.kg)("Key","key"),(0,f.kg)("Method","method"),(0,f.kg)("Module","module"),(0,f.kg)("Namespace","namespace"),(0,f.kg)("Null","null"),(0,f.kg)("Number","number"),(0,f.kg)("Object","object"),(0,f.kg)("Operator","operator"),(0,f.kg)("Package","package"),(0,f.kg)("Property","property"),(0,f.kg)("String","string"),(0,f.kg)("Struct","struct"),(0,f.kg)("TypeParameter","type parameter"),(0,f.kg)("Variable","variable");var b,_,k,v,C;!function(e){const t=new Map;t.set(0,r.W.symbolFile),t.set(1,r.W.symbolModule),t.set(2,r.W.symbolNamespace),t.set(3,r.W.symbolPackage),t.set(4,r.W.symbolClass),t.set(5,r.W.symbolMethod),t.set(6,r.W.symbolProperty),t.set(7,r.W.symbolField),t.set(8,r.W.symbolConstructor),t.set(9,r.W.symbolEnum),t.set(10,r.W.symbolInterface),t.set(11,r.W.symbolFunction),t.set(12,r.W.symbolVariable),t.set(13,r.W.symbolConstant),t.set(14,r.W.symbolString),t.set(15,r.W.symbolNumber),t.set(16,r.W.symbolBoolean),t.set(17,r.W.symbolArray),t.set(18,r.W.symbolObject),t.set(19,r.W.symbolKey),t.set(20,r.W.symbolNull),t.set(21,r.W.symbolEnumMember),t.set(22,r.W.symbolStruct),t.set(23,r.W.symbolEvent),t.set(24,r.W.symbolOperator),t.set(25,r.W.symbolTypeParameter),e.toIcon=function(e){let n=t.get(e);return n||(console.info("No codicon found for SymbolKind "+e),n=r.W.symbolProperty),n}}(b||(b={}));class y{static{this.Comment=new y("comment")}static{this.Imports=new y("imports")}static{this.Region=new y("region")}static fromValue(e){switch(e){case"comment":return y.Comment;case"imports":return y.Imports;case"region":return y.Region}return new y(e)}constructor(e){this.value=e}}!function(e){e[e.AIGenerated=1]="AIGenerated"}(_||(_={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(k||(k={})),function(e){e.is=function(e){return!(!e||"object"!==typeof e)&&("string"===typeof e.id&&"string"===typeof e.title)}}(v||(v={})),function(e){e[e.Type=1]="Type",e[e.Parameter=2]="Parameter"}(C||(C={}));const L=new o,w=new o;var S;!function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(S||(S={}))},2522:(e,t,n)=>{"use strict";var r;n.d(t,{f:()=>r}),function(e){function t(e){return e&&"object"===typeof e&&"function"===typeof e[Symbol.iterator]}e.is=t;const n=Object.freeze([]);function*r(e){yield e}e.empty=function(){return n},e.single=r,e.wrap=function(e){return t(e)?e:r(e)},e.from=function(e){return e||n},e.reverse=function*(e){for(let t=e.length-1;t>=0;t--)yield e[t]},e.isEmpty=function(e){return!e||!0===e[Symbol.iterator]().next().done},e.first=function(e){return e[Symbol.iterator]().next().value},e.some=function(e,t){let n=0;for(const r of e)if(t(r,n++))return!0;return!1},e.find=function(e,t){for(const n of e)if(t(n))return n},e.filter=function*(e,t){for(const n of e)t(n)&&(yield n)},e.map=function*(e,t){let n=0;for(const r of e)yield t(r,n++)},e.flatMap=function*(e,t){let n=0;for(const r of e)yield*t(r,n++)},e.concat=function*(...e){for(const t of e)yield*t},e.reduce=function(e,t,n){let r=n;for(const i of e)r=t(r,i);return r},e.slice=function*(e,t,n=e.length){for(t<0&&(t+=e.length),n<0?n+=e.length:n>e.length&&(n=e.length);ti}]},e.asyncToArray=async function(e){const t=[];for await(const n of e)t.push(n);return Promise.resolve(t)}}(r||(r={}))},2661:(e,t,n)=>{"use strict";n.r(t),n.d(t,{LanguageFeaturesService:()=>m});var r=n(1234),i=n(1484),s=n(6223),o=n(6958),a=n(8821);function l(e,t,n,r,i,s){if(Array.isArray(e)){let o=0;for(const a of e){const e=l(a,t,n,r,i,s);if(10===e)return e;e>o&&(o=e)}return o}if("string"===typeof e)return r?"*"===e?5:e===n?10:0:0;if(e){const{language:l,pattern:c,scheme:h,hasAccessToAllModels:u,notebookType:d}=e;if(!r&&!u)return 0;d&&i&&(t=i);let g=0;if(h)if(h===t.scheme)g=10;else{if("*"!==h)return 0;g=5}if(l)if(l===n)g=10;else{if("*"!==l)return 0;g=Math.max(g,5)}if(d)if(d===s)g=10;else{if("*"!==d||void 0===s)return 0;g=Math.max(g,5)}if(c){let e;if(e="string"===typeof c?c:{...c,base:(0,a.S8)(c.base)},e!==t.fsPath&&!(0,o.YW)(e,t.fsPath))return 0;g=10}return g}return 0}function c(e){return"string"!==typeof e&&(Array.isArray(e)?e.every(c):!!e.exclusive)}class h{constructor(e,t,n,r,i){this.uri=e,this.languageId=t,this.notebookUri=n,this.notebookType=r,this.recursive=i}equals(e){return this.notebookType===e.notebookType&&this.languageId===e.languageId&&this.uri.toString()===e.uri.toString()&&this.notebookUri?.toString()===e.notebookUri?.toString()&&this.recursive===e.recursive}}class u{constructor(e){this._notebookInfoResolver=e,this._clock=0,this._entries=[],this._onDidChange=new r.vl,this.onDidChange=this._onDidChange.event}register(e,t){let n={selector:e,provider:t,_score:-1,_time:this._clock++};return this._entries.push(n),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),(0,i.s)((()=>{if(n){const e=this._entries.indexOf(n);e>=0&&(this._entries.splice(e,1),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),n=void 0)}}))}has(e){return this.all(e).length>0}all(e){if(!e)return[];this._updateScores(e,!1);const t=[];for(const n of this._entries)n._score>0&&t.push(n.provider);return t}ordered(e,t=!1){const n=[];return this._orderedForEach(e,t,(e=>n.push(e.provider))),n}orderedGroups(e){const t=[];let n,r;return this._orderedForEach(e,!1,(e=>{n&&r===e._score?n.push(e.provider):(r=e._score,n=[e.provider],t.push(n))})),t}_orderedForEach(e,t,n){this._updateScores(e,t);for(const r of this._entries)r._score>0&&n(r)}_updateScores(e,t){const n=this._notebookInfoResolver?.(e.uri),r=n?new h(e.uri,e.getLanguageId(),n.uri,n.type,t):new h(e.uri,e.getLanguageId(),void 0,void 0,t);if(!this._lastCandidate?.equals(r)){this._lastCandidate=r;for(const n of this._entries)if(n._score=l(n.selector,r.uri,r.languageId,(0,s.vd)(e),r.notebookUri,r.notebookType),c(n.selector)&&n._score>0){if(!t){for(const e of this._entries)e._score=0;n._score=1e3;break}n._score=0}this._entries.sort(u._compareByScoreAndTime)}}static _compareByScoreAndTime(e,t){return e._scoret._score?-1:d(e.selector)&&!d(t.selector)?1:!d(e.selector)&&d(t.selector)?-1:e._timet._time?-1:0}}function d(e){return"string"!==typeof e&&(Array.isArray(e)?e.some(d):Boolean(e.isBuiltin))}var g=n(6942),f=n(4621);class m{constructor(){this.referenceProvider=new u(this._score.bind(this)),this.renameProvider=new u(this._score.bind(this)),this.newSymbolNamesProvider=new u(this._score.bind(this)),this.codeActionProvider=new u(this._score.bind(this)),this.definitionProvider=new u(this._score.bind(this)),this.typeDefinitionProvider=new u(this._score.bind(this)),this.declarationProvider=new u(this._score.bind(this)),this.implementationProvider=new u(this._score.bind(this)),this.documentSymbolProvider=new u(this._score.bind(this)),this.inlayHintsProvider=new u(this._score.bind(this)),this.colorProvider=new u(this._score.bind(this)),this.codeLensProvider=new u(this._score.bind(this)),this.documentFormattingEditProvider=new u(this._score.bind(this)),this.documentRangeFormattingEditProvider=new u(this._score.bind(this)),this.onTypeFormattingEditProvider=new u(this._score.bind(this)),this.signatureHelpProvider=new u(this._score.bind(this)),this.hoverProvider=new u(this._score.bind(this)),this.documentHighlightProvider=new u(this._score.bind(this)),this.multiDocumentHighlightProvider=new u(this._score.bind(this)),this.selectionRangeProvider=new u(this._score.bind(this)),this.foldingRangeProvider=new u(this._score.bind(this)),this.linkProvider=new u(this._score.bind(this)),this.inlineCompletionsProvider=new u(this._score.bind(this)),this.inlineEditProvider=new u(this._score.bind(this)),this.completionProvider=new u(this._score.bind(this)),this.linkedEditingRangeProvider=new u(this._score.bind(this)),this.documentRangeSemanticTokensProvider=new u(this._score.bind(this)),this.documentSemanticTokensProvider=new u(this._score.bind(this)),this.documentDropEditProvider=new u(this._score.bind(this)),this.documentPasteEditProvider=new u(this._score.bind(this))}_score(e){return this._notebookTypeResolver?.(e)}}(0,f.v)(g.ILanguageFeaturesService,m,1)},3069:(e,t,n)=>{"use strict";n.d(t,{y:()=>r});class r{constructor(e,t){this.lineNumber=e,this.column=t}with(e=this.lineNumber,t=this.column){return e===this.lineNumber&&t===this.column?this:new r(e,t)}delta(e=0,t=0){return this.with(this.lineNumber+e,this.column+t)}equals(e){return r.equals(this,e)}static equals(e,t){return!e&&!t||!!e&&!!t&&e.lineNumber===t.lineNumber&&e.column===t.column}isBefore(e){return r.isBefore(this,e)}static isBefore(e,t){return e.lineNumber{"use strict";n.d(t,{rr:()=>Q,$b:()=>J});n(1234);var r=n(1484),i=n(8067),s=n(1508),o=n(4383),a=n(8209);function l(...e){switch(e.length){case 1:return(0,a.kg)("contextkey.scanner.hint.didYouMean1","Did you mean {0}?",e[0]);case 2:return(0,a.kg)("contextkey.scanner.hint.didYouMean2","Did you mean {0} or {1}?",e[0],e[1]);case 3:return(0,a.kg)("contextkey.scanner.hint.didYouMean3","Did you mean {0}, {1} or {2}?",e[0],e[1],e[2]);default:return}}const c=(0,a.kg)("contextkey.scanner.hint.didYouForgetToOpenOrCloseQuote","Did you forget to open or close the quote?"),h=(0,a.kg)("contextkey.scanner.hint.didYouForgetToEscapeSlash","Did you forget to escape the '/' (slash) character? Put two backslashes before it to escape, e.g., '\\\\/'.");class u{constructor(){this._input="",this._start=0,this._current=0,this._tokens=[],this._errors=[],this.stringRe=/[a-zA-Z0-9_<>\-\./\\:\*\?\+\[\]\^,#@;"%\$\p{L}-]+/uy}static getLexeme(e){switch(e.type){case 0:return"(";case 1:return")";case 2:return"!";case 3:return e.isTripleEq?"===":"==";case 4:return e.isTripleEq?"!==":"!=";case 5:return"<";case 6:return"<=";case 7:case 8:return">=";case 9:return"=~";case 10:case 17:case 18:case 19:return e.lexeme;case 11:return"true";case 12:return"false";case 13:return"in";case 14:return"not";case 15:return"&&";case 16:return"||";case 20:return"EOF";default:throw(0,o.iH)(`unhandled token type: ${JSON.stringify(e)}; have you forgotten to add a case?`)}}static{this._regexFlags=new Set(["i","g","s","m","y","u"].map((e=>e.charCodeAt(0))))}static{this._keywords=new Map([["not",14],["in",13],["false",12],["true",11]])}reset(e){return this._input=e,this._start=0,this._current=0,this._tokens=[],this._errors=[],this}scan(){for(;!this._isAtEnd();){this._start=this._current;switch(this._advance()){case 40:this._addToken(0);break;case 41:this._addToken(1);break;case 33:if(this._match(61)){const e=this._match(61);this._tokens.push({type:4,offset:this._start,isTripleEq:e})}else this._addToken(2);break;case 39:this._quotedString();break;case 47:this._regex();break;case 61:if(this._match(61)){const e=this._match(61);this._tokens.push({type:3,offset:this._start,isTripleEq:e})}else this._match(126)?this._addToken(9):this._error(l("==","=~"));break;case 60:this._addToken(this._match(61)?6:5);break;case 62:this._addToken(this._match(61)?8:7);break;case 38:this._match(38)?this._addToken(15):this._error(l("&&"));break;case 124:this._match(124)?this._addToken(16):this._error(l("||"));break;case 32:case 13:case 9:case 10:case 160:break;default:this._string()}}return this._start=this._current,this._addToken(20),Array.from(this._tokens)}_match(e){return!this._isAtEnd()&&(this._input.charCodeAt(this._current)===e&&(this._current++,!0))}_advance(){return this._input.charCodeAt(this._current++)}_peek(){return this._isAtEnd()?0:this._input.charCodeAt(this._current)}_addToken(e){this._tokens.push({type:e,offset:this._start})}_error(e){const t=this._start,n=this._input.substring(this._start,this._current),r={type:19,offset:this._start,lexeme:n};this._errors.push({offset:t,lexeme:n,additionalInfo:e}),this._tokens.push(r)}_string(){this.stringRe.lastIndex=this._start;const e=this.stringRe.exec(this._input);if(e){this._current=this._start+e[0].length;const t=this._input.substring(this._start,this._current),n=u._keywords.get(t);n?this._addToken(n):this._tokens.push({type:17,lexeme:t,offset:this._start})}}_quotedString(){for(;39!==this._peek()&&!this._isAtEnd();)this._advance();this._isAtEnd()?this._error(c):(this._advance(),this._tokens.push({type:18,lexeme:this._input.substring(this._start+1,this._current-1),offset:this._start+1}))}_regex(){let e=this._current,t=!1,n=!1;for(;;){if(e>=this._input.length)return this._current=e,void this._error(h);const r=this._input.charCodeAt(e);if(t)t=!1;else{if(47===r&&!n){e++;break}91===r?n=!0:92===r?t=!0:93===r&&(n=!1)}e++}for(;e=this._input.length}}var d=n(3591);const g=new Map;g.set("false",!1),g.set("true",!0),g.set("isMac",i.zx),g.set("isLinux",i.j9),g.set("isWindows",i.uF),g.set("isWeb",i.HZ),g.set("isMacNative",i.zx&&!i.HZ),g.set("isEdge",i.UP),g.set("isFirefox",i.gm),g.set("isChrome",i.H8),g.set("isSafari",i.nr);const f=Object.prototype.hasOwnProperty,m={regexParsingWithErrorRecovery:!0},p=(0,a.kg)("contextkey.parser.error.emptyString","Empty context key expression"),b=(0,a.kg)("contextkey.parser.error.emptyString.hint","Did you forget to write an expression? You can also put 'false' or 'true' to always evaluate to false or true, respectively."),_=(0,a.kg)("contextkey.parser.error.noInAfterNot","'in' after 'not'."),k=(0,a.kg)("contextkey.parser.error.closingParenthesis","closing parenthesis ')'"),v=(0,a.kg)("contextkey.parser.error.unexpectedToken","Unexpected token"),C=(0,a.kg)("contextkey.parser.error.unexpectedToken.hint","Did you forget to put && or || before the token?"),y=(0,a.kg)("contextkey.parser.error.unexpectedEOF","Unexpected end of expression"),L=(0,a.kg)("contextkey.parser.error.unexpectedEOF.hint","Did you forget to put a context key?");class w{static{this._parseError=new Error}constructor(e=m){this._config=e,this._scanner=new u,this._tokens=[],this._current=0,this._parsingErrors=[],this._flagsGYRe=/g|y/g}parse(e){if(""!==e){this._tokens=this._scanner.reset(e).scan(),this._current=0,this._parsingErrors=[];try{const e=this._expr();if(!this._isAtEnd()){const e=this._peek(),t=17===e.type?C:void 0;throw this._parsingErrors.push({message:v,offset:e.offset,lexeme:u.getLexeme(e),additionalInfo:t}),w._parseError}return e}catch(t){if(t!==w._parseError)throw t;return}}else this._parsingErrors.push({message:p,offset:0,lexeme:"",additionalInfo:b})}_expr(){return this._or()}_or(){const e=[this._and()];for(;this._matchOne(16);){const t=this._and();e.push(t)}return 1===e.length?e[0]:S.or(...e)}_and(){const e=[this._term()];for(;this._matchOne(15);){const t=this._term();e.push(t)}return 1===e.length?e[0]:S.and(...e)}_term(){if(this._matchOne(2)){const e=this._peek();switch(e.type){case 11:return this._advance(),E.INSTANCE;case 12:return this._advance(),N.INSTANCE;case 0:{this._advance();const e=this._expr();return this._consume(1,k),e?.negate()}case 17:return this._advance(),R.create(e.lexeme);default:throw this._errExpectedButGot("KEY | true | false | '(' expression ')'",e)}}return this._primary()}_primary(){const e=this._peek();switch(e.type){case 11:return this._advance(),S.true();case 12:return this._advance(),S.false();case 0:{this._advance();const e=this._expr();return this._consume(1,k),e}case 17:{const r=e.lexeme;if(this._advance(),this._matchOne(9)){const e=this._peek();if(!this._config.regexParsingWithErrorRecovery){if(this._advance(),10!==e.type)throw this._errExpectedButGot("REGEX",e);const n=e.lexeme,i=n.lastIndexOf("/"),s=i===n.length-1?void 0:this._removeFlagsGY(n.substring(i+1));let o;try{o=new RegExp(n.substring(1,i),s)}catch(t){throw this._errExpectedButGot("REGEX",e)}return z.create(r,o)}switch(e.type){case 10:case 19:{const n=[e.lexeme];this._advance();let i=this._peek(),s=0;for(let t=0;t=0){const o=t.slice(r+1,s),a="i"===t[s+1]?"i":"";try{i=new RegExp(o,a)}catch(n){throw this._errExpectedButGot("REGEX",e)}}}if(null===i)throw this._errExpectedButGot("REGEX",e);return z.create(r,i)}default:throw this._errExpectedButGot("REGEX",this._peek())}}if(this._matchOne(14)){this._consume(13,_);const e=this._value();return S.notIn(r,e)}switch(this._peek().type){case 3:{this._advance();const e=this._value();if(18===this._previous().type)return S.equals(r,e);switch(e){case"true":return S.has(r);case"false":return S.not(r);default:return S.equals(r,e)}}case 4:{this._advance();const e=this._value();if(18===this._previous().type)return S.notEquals(r,e);switch(e){case"true":return S.not(r);case"false":return S.has(r);default:return S.notEquals(r,e)}}case 5:return this._advance(),P.create(r,this._value());case 6:return this._advance(),V.create(r,this._value());case 7:return this._advance(),B.create(r,this._value());case 8:return this._advance(),F.create(r,this._value());case 13:return this._advance(),S.in(r,this._value());default:return S.has(r)}}case 20:throw this._parsingErrors.push({message:y,offset:e.offset,lexeme:"",additionalInfo:L}),w._parseError;default:throw this._errExpectedButGot("true | false | KEY \n\t| KEY '=~' REGEX \n\t| KEY ('==' | '!=' | '<' | '<=' | '>' | '>=' | 'in' | 'not' 'in') value",this._peek())}}_value(){const e=this._peek();switch(e.type){case 17:case 18:return this._advance(),e.lexeme;case 11:return this._advance(),"true";case 12:return this._advance(),"false";case 13:return this._advance(),"in";default:return""}}_removeFlagsGY(e){return e.replaceAll(this._flagsGYRe,"")}_previous(){return this._tokens[this._current-1]}_matchOne(e){return!!this._check(e)&&(this._advance(),!0)}_advance(){return this._isAtEnd()||this._current++,this._previous()}_consume(e,t){if(this._check(e))return this._advance();throw this._errExpectedButGot(t,this._peek())}_errExpectedButGot(e,t,n){const r=(0,a.kg)("contextkey.parser.error.expectedButGot","Expected: {0}\nReceived: '{1}'.",e,u.getLexeme(t)),i=t.offset,s=u.getLexeme(t);return this._parsingErrors.push({message:r,offset:i,lexeme:s,additionalInfo:n}),w._parseError}_check(e){return this._peek().type===e}_peek(){return this._tokens[this._current]}_isAtEnd(){return 20===this._peek().type}}class S{static false(){return E.INSTANCE}static true(){return N.INSTANCE}static has(e){return T.create(e)}static equals(e,t){return A.create(e,t)}static notEquals(e,t){return M.create(e,t)}static regex(e,t){return z.create(e,t)}static in(e,t){return I.create(e,t)}static notIn(e,t){return O.create(e,t)}static not(e){return R.create(e)}static and(...e){return W.create(e,null,!0)}static or(...e){return U.create(e,null,!0)}static{this._parser=new w({regexParsingWithErrorRecovery:!1})}static deserialize(e){if(void 0===e||null===e)return;return this._parser.parse(e)}}function x(e,t){return e.cmp(t)}class E{static{this.INSTANCE=new E}constructor(){this.type=0}cmp(e){return this.type-e.type}equals(e){return e.type===this.type}substituteConstants(){return this}evaluate(e){return!1}serialize(){return"false"}keys(){return[]}negate(){return N.INSTANCE}}class N{static{this.INSTANCE=new N}constructor(){this.type=1}cmp(e){return this.type-e.type}equals(e){return e.type===this.type}substituteConstants(){return this}evaluate(e){return!0}serialize(){return"true"}keys(){return[]}negate(){return E.INSTANCE}}class T{static create(e,t=null){const n=g.get(e);return"boolean"===typeof n?n?N.INSTANCE:E.INSTANCE:new T(e,t)}constructor(e,t){this.key=e,this.negated=t,this.type=2}cmp(e){return e.type!==this.type?this.type-e.type:H(this.key,e.key)}equals(e){return e.type===this.type&&this.key===e.key}substituteConstants(){const e=g.get(this.key);return"boolean"===typeof e?e?N.INSTANCE:E.INSTANCE:this}evaluate(e){return!!e.getValue(this.key)}serialize(){return this.key}keys(){return[this.key]}negate(){return this.negated||(this.negated=R.create(this.key,this)),this.negated}}class A{static create(e,t,n=null){if("boolean"===typeof t)return t?T.create(e,n):R.create(e,n);const r=g.get(e);if("boolean"===typeof r){return t===(r?"true":"false")?N.INSTANCE:E.INSTANCE}return new A(e,t,n)}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=4}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){const e=g.get(this.key);if("boolean"===typeof e){const t=e?"true":"false";return this.value===t?N.INSTANCE:E.INSTANCE}return this}evaluate(e){return e.getValue(this.key)==this.value}serialize(){return`${this.key} == '${this.value}'`}keys(){return[this.key]}negate(){return this.negated||(this.negated=M.create(this.key,this.value,this)),this.negated}}class I{static create(e,t){return new I(e,t)}constructor(e,t){this.key=e,this.valueKey=t,this.type=10,this.negated=null}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.valueKey,e.key,e.valueKey)}equals(e){return e.type===this.type&&(this.key===e.key&&this.valueKey===e.valueKey)}substituteConstants(){return this}evaluate(e){const t=e.getValue(this.valueKey),n=e.getValue(this.key);return Array.isArray(t)?t.includes(n):"string"===typeof n&&"object"===typeof t&&null!==t&&f.call(t,n)}serialize(){return`${this.key} in '${this.valueKey}'`}keys(){return[this.key,this.valueKey]}negate(){return this.negated||(this.negated=O.create(this.key,this.valueKey)),this.negated}}class O{static create(e,t){return new O(e,t)}constructor(e,t){this.key=e,this.valueKey=t,this.type=11,this._negated=I.create(e,t)}cmp(e){return e.type!==this.type?this.type-e.type:this._negated.cmp(e._negated)}equals(e){return e.type===this.type&&this._negated.equals(e._negated)}substituteConstants(){return this}evaluate(e){return!this._negated.evaluate(e)}serialize(){return`${this.key} not in '${this.valueKey}'`}keys(){return this._negated.keys()}negate(){return this._negated}}class M{static create(e,t,n=null){if("boolean"===typeof t)return t?R.create(e,n):T.create(e,n);const r=g.get(e);if("boolean"===typeof r){return t===(r?"true":"false")?E.INSTANCE:N.INSTANCE}return new M(e,t,n)}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=5}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){const e=g.get(this.key);if("boolean"===typeof e){const t=e?"true":"false";return this.value===t?E.INSTANCE:N.INSTANCE}return this}evaluate(e){return e.getValue(this.key)!=this.value}serialize(){return`${this.key} != '${this.value}'`}keys(){return[this.key]}negate(){return this.negated||(this.negated=A.create(this.key,this.value,this)),this.negated}}class R{static create(e,t=null){const n=g.get(e);return"boolean"===typeof n?n?E.INSTANCE:N.INSTANCE:new R(e,t)}constructor(e,t){this.key=e,this.negated=t,this.type=3}cmp(e){return e.type!==this.type?this.type-e.type:H(this.key,e.key)}equals(e){return e.type===this.type&&this.key===e.key}substituteConstants(){const e=g.get(this.key);return"boolean"===typeof e?e?E.INSTANCE:N.INSTANCE:this}evaluate(e){return!e.getValue(this.key)}serialize(){return`!${this.key}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=T.create(this.key,this)),this.negated}}function D(e,t){if("string"===typeof e){const t=parseFloat(e);isNaN(t)||(e=t)}return"string"===typeof e||"number"===typeof e?t(e):E.INSTANCE}class B{static create(e,t,n=null){return D(t,(t=>new B(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=12}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))>this.value}serialize(){return`${this.key} > ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=V.create(this.key,this.value,this)),this.negated}}class F{static create(e,t,n=null){return D(t,(t=>new F(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=13}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))>=this.value}serialize(){return`${this.key} >= ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=P.create(this.key,this.value,this)),this.negated}}class P{static create(e,t,n=null){return D(t,(t=>new P(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=14}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))new V(e,t,n)))}constructor(e,t,n){this.key=e,this.value=t,this.negated=n,this.type=15}cmp(e){return e.type!==this.type?this.type-e.type:K(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))<=this.value}serialize(){return`${this.key} <= ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=B.create(this.key,this.value,this)),this.negated}}class z{static create(e,t){return new z(e,t)}constructor(e,t){this.key=e,this.regexp=t,this.type=7,this.negated=null}cmp(e){if(e.type!==this.type)return this.type-e.type;if(this.keye.key)return 1;const t=this.regexp?this.regexp.source:"",n=e.regexp?e.regexp.source:"";return tn?1:0}equals(e){if(e.type===this.type){const t=this.regexp?this.regexp.source:"",n=e.regexp?e.regexp.source:"";return this.key===e.key&&t===n}return!1}substituteConstants(){return this}evaluate(e){const t=e.getValue(this.key);return!!this.regexp&&this.regexp.test(t)}serialize(){const e=this.regexp?`/${this.regexp.source}/${this.regexp.flags}`:"/invalid/";return`${this.key} =~ ${e}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=j.create(this)),this.negated}}class j{static create(e){return new j(e)}constructor(e){this._actual=e,this.type=8}cmp(e){return e.type!==this.type?this.type-e.type:this._actual.cmp(e._actual)}equals(e){return e.type===this.type&&this._actual.equals(e._actual)}substituteConstants(){return this}evaluate(e){return!this._actual.evaluate(e)}serialize(){return`!(${this._actual.serialize()})`}keys(){return this._actual.keys()}negate(){return this._actual}}function q(e){let t=null;for(let n=0,r=e.length;ne.expr.length)return 1;for(let t=0,n=this.expr.length;t1;){const e=r[r.length-1];if(9!==e.type)break;r.pop();const t=r.pop(),i=0===r.length,s=U.create(e.expr.map((e=>W.create([e,t],null,n))),null,i);s&&(r.push(s),r.sort(x))}if(1===r.length)return r[0];if(n){for(let e=0;ee.serialize())).join(" && ")}keys(){const e=[];for(const t of this.expr)e.push(...t.keys());return e}negate(){if(!this.negated){const e=[];for(const t of this.expr)e.push(t.negate());this.negated=U.create(e,this,!0)}return this.negated}}class U{static create(e,t,n){return U._normalizeArr(e,t,n)}constructor(e,t){this.expr=e,this.negated=t,this.type=9}cmp(e){if(e.type!==this.type)return this.type-e.type;if(this.expr.lengthe.expr.length)return 1;for(let t=0,n=this.expr.length;te.serialize())).join(" || ")}keys(){const e=[];for(const t of this.expr)e.push(...t.keys());return e}negate(){if(!this.negated){const e=[];for(const t of this.expr)e.push(t.negate());for(;e.length>1;){const t=e.shift(),n=e.shift(),r=[];for(const e of G(t))for(const t of G(n))r.push(W.create([e,t],null,!1));e.unshift(U.create(r,null,!1))}this.negated=U.create(e,this,!0)}return this.negated}}class $ extends T{static{this._info=[]}static all(){return $._info.values()}constructor(e,t,n){super(e,null),this._defaultValue=t,"object"===typeof n?$._info.push({...n,key:e}):!0!==n&&$._info.push({key:e,description:n,type:null!==t&&void 0!==t?typeof t:void 0})}bindTo(e){return e.createKey(this.key,this._defaultValue)}getValue(e){return e.getContextKeyValue(this.key)}toNegated(){return this.negate()}isEqualTo(e){return A.create(this.key,e)}}(0,d.u1)("contextKeyService");function H(e,t){return et?1:0}function K(e,t,n,r){return en?1:tr?1:0}function G(e){return 9===e.type?e.expr:[e]}const Q=(0,d.u1)("logService");var J;!function(e){e[e.Off=0]="Off",e[e.Trace=1]="Trace",e[e.Debug=2]="Debug",e[e.Info=3]="Info",e[e.Warning=4]="Warning",e[e.Error=5]="Error"}(J||(J={}));J.Info;r.jG;new $("logLevel",function(e){switch(e){case J.Trace:return"trace";case J.Debug:return"debug";case J.Info:return"info";case J.Warning:return"warn";case J.Error:return"error";case J.Off:return"off"}}(J.Info))},3591:(e,t,n)=>{"use strict";var r;n.d(t,{_Y:()=>i,u1:()=>s}),function(e){e.serviceIds=new Map,e.DI_TARGET="$di$target",e.DI_DEPENDENCIES="$di$dependencies",e.getServiceDependencies=function(t){return t[e.DI_DEPENDENCIES]||[]}}(r||(r={}));const i=s("instantiationService");function s(e){if(r.serviceIds.has(e))return r.serviceIds.get(e);const t=function(e,n,i){if(3!==arguments.length)throw new Error("@IServiceName-decorator can only be used to decorate a parameter");!function(e,t,n){t[r.DI_TARGET]===t?t[r.DI_DEPENDENCIES].push({id:e,index:n}):(t[r.DI_DEPENDENCIES]=[{id:e,index:n}],t[r.DI_TARGET]=t)}(t,e,i)};return t.toString=()=>e,r.serviceIds.set(e,t),t}},3750:(e,t,n)=>{"use strict";n.r(t),n.d(t,{IModelService:()=>r});const r=(0,n(3591).u1)("modelService")},3941:(e,t,n)=>{"use strict";n.d(t,{W6:()=>l,vH:()=>c});var r=n(8209),i=n(1234),s=n(6359),o=n(1939),a=n(1646);const l=new class{constructor(){this._onDidChangeLanguages=new i.vl,this.onDidChangeLanguages=this._onDidChangeLanguages.event,this._languages=[]}registerLanguage(e){return this._languages.push(e),this._onDidChangeLanguages.fire(void 0),{dispose:()=>{for(let t=0,n=this._languages.length;t{"use strict";n.d(t,{Mo:()=>i,pG:()=>r});const r=(0,n(3591).u1)("configurationService");function i(e){return e.replace(/[\[\]]/g,"")}},4243:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ISemanticTokensStylingService:()=>r});const r=(0,n(3591).u1)("semanticTokensStylingService")},4272:(e,t,n)=>{"use strict";n.r(t),n.d(t,{KeyMod:()=>fe,createMonacoBaseAPI:()=>me});var r=n(8447),i=n(1234);class s{constructor(){this._keyCodeToStr=[],this._strToKeyCode=Object.create(null)}define(e,t){this._keyCodeToStr[e]=t,this._strToKeyCode[t.toLowerCase()]=e}keyCodeToStr(e){return this._keyCodeToStr[e]}strToKeyCode(e){return this._strToKeyCode[e.toLowerCase()]||0}}const o=new s,a=new s,l=new s,c=new Array(230),h={},u=[],d=Object.create(null),g=Object.create(null),f=[],m=[];for(let pe=0;pe<=193;pe++)f[pe]=-1;for(let pe=0;pe<=132;pe++)m[pe]=-1;var p;!function(){const e="",t=[[1,0,"None",0,"unknown",0,"VK_UNKNOWN",e,e],[1,1,"Hyper",0,e,0,e,e,e],[1,2,"Super",0,e,0,e,e,e],[1,3,"Fn",0,e,0,e,e,e],[1,4,"FnLock",0,e,0,e,e,e],[1,5,"Suspend",0,e,0,e,e,e],[1,6,"Resume",0,e,0,e,e,e],[1,7,"Turbo",0,e,0,e,e,e],[1,8,"Sleep",0,e,0,"VK_SLEEP",e,e],[1,9,"WakeUp",0,e,0,e,e,e],[0,10,"KeyA",31,"A",65,"VK_A",e,e],[0,11,"KeyB",32,"B",66,"VK_B",e,e],[0,12,"KeyC",33,"C",67,"VK_C",e,e],[0,13,"KeyD",34,"D",68,"VK_D",e,e],[0,14,"KeyE",35,"E",69,"VK_E",e,e],[0,15,"KeyF",36,"F",70,"VK_F",e,e],[0,16,"KeyG",37,"G",71,"VK_G",e,e],[0,17,"KeyH",38,"H",72,"VK_H",e,e],[0,18,"KeyI",39,"I",73,"VK_I",e,e],[0,19,"KeyJ",40,"J",74,"VK_J",e,e],[0,20,"KeyK",41,"K",75,"VK_K",e,e],[0,21,"KeyL",42,"L",76,"VK_L",e,e],[0,22,"KeyM",43,"M",77,"VK_M",e,e],[0,23,"KeyN",44,"N",78,"VK_N",e,e],[0,24,"KeyO",45,"O",79,"VK_O",e,e],[0,25,"KeyP",46,"P",80,"VK_P",e,e],[0,26,"KeyQ",47,"Q",81,"VK_Q",e,e],[0,27,"KeyR",48,"R",82,"VK_R",e,e],[0,28,"KeyS",49,"S",83,"VK_S",e,e],[0,29,"KeyT",50,"T",84,"VK_T",e,e],[0,30,"KeyU",51,"U",85,"VK_U",e,e],[0,31,"KeyV",52,"V",86,"VK_V",e,e],[0,32,"KeyW",53,"W",87,"VK_W",e,e],[0,33,"KeyX",54,"X",88,"VK_X",e,e],[0,34,"KeyY",55,"Y",89,"VK_Y",e,e],[0,35,"KeyZ",56,"Z",90,"VK_Z",e,e],[0,36,"Digit1",22,"1",49,"VK_1",e,e],[0,37,"Digit2",23,"2",50,"VK_2",e,e],[0,38,"Digit3",24,"3",51,"VK_3",e,e],[0,39,"Digit4",25,"4",52,"VK_4",e,e],[0,40,"Digit5",26,"5",53,"VK_5",e,e],[0,41,"Digit6",27,"6",54,"VK_6",e,e],[0,42,"Digit7",28,"7",55,"VK_7",e,e],[0,43,"Digit8",29,"8",56,"VK_8",e,e],[0,44,"Digit9",30,"9",57,"VK_9",e,e],[0,45,"Digit0",21,"0",48,"VK_0",e,e],[1,46,"Enter",3,"Enter",13,"VK_RETURN",e,e],[1,47,"Escape",9,"Escape",27,"VK_ESCAPE",e,e],[1,48,"Backspace",1,"Backspace",8,"VK_BACK",e,e],[1,49,"Tab",2,"Tab",9,"VK_TAB",e,e],[1,50,"Space",10,"Space",32,"VK_SPACE",e,e],[0,51,"Minus",88,"-",189,"VK_OEM_MINUS","-","OEM_MINUS"],[0,52,"Equal",86,"=",187,"VK_OEM_PLUS","=","OEM_PLUS"],[0,53,"BracketLeft",92,"[",219,"VK_OEM_4","[","OEM_4"],[0,54,"BracketRight",94,"]",221,"VK_OEM_6","]","OEM_6"],[0,55,"Backslash",93,"\\",220,"VK_OEM_5","\\","OEM_5"],[0,56,"IntlHash",0,e,0,e,e,e],[0,57,"Semicolon",85,";",186,"VK_OEM_1",";","OEM_1"],[0,58,"Quote",95,"'",222,"VK_OEM_7","'","OEM_7"],[0,59,"Backquote",91,"`",192,"VK_OEM_3","`","OEM_3"],[0,60,"Comma",87,",",188,"VK_OEM_COMMA",",","OEM_COMMA"],[0,61,"Period",89,".",190,"VK_OEM_PERIOD",".","OEM_PERIOD"],[0,62,"Slash",90,"/",191,"VK_OEM_2","/","OEM_2"],[1,63,"CapsLock",8,"CapsLock",20,"VK_CAPITAL",e,e],[1,64,"F1",59,"F1",112,"VK_F1",e,e],[1,65,"F2",60,"F2",113,"VK_F2",e,e],[1,66,"F3",61,"F3",114,"VK_F3",e,e],[1,67,"F4",62,"F4",115,"VK_F4",e,e],[1,68,"F5",63,"F5",116,"VK_F5",e,e],[1,69,"F6",64,"F6",117,"VK_F6",e,e],[1,70,"F7",65,"F7",118,"VK_F7",e,e],[1,71,"F8",66,"F8",119,"VK_F8",e,e],[1,72,"F9",67,"F9",120,"VK_F9",e,e],[1,73,"F10",68,"F10",121,"VK_F10",e,e],[1,74,"F11",69,"F11",122,"VK_F11",e,e],[1,75,"F12",70,"F12",123,"VK_F12",e,e],[1,76,"PrintScreen",0,e,0,e,e,e],[1,77,"ScrollLock",84,"ScrollLock",145,"VK_SCROLL",e,e],[1,78,"Pause",7,"PauseBreak",19,"VK_PAUSE",e,e],[1,79,"Insert",19,"Insert",45,"VK_INSERT",e,e],[1,80,"Home",14,"Home",36,"VK_HOME",e,e],[1,81,"PageUp",11,"PageUp",33,"VK_PRIOR",e,e],[1,82,"Delete",20,"Delete",46,"VK_DELETE",e,e],[1,83,"End",13,"End",35,"VK_END",e,e],[1,84,"PageDown",12,"PageDown",34,"VK_NEXT",e,e],[1,85,"ArrowRight",17,"RightArrow",39,"VK_RIGHT","Right",e],[1,86,"ArrowLeft",15,"LeftArrow",37,"VK_LEFT","Left",e],[1,87,"ArrowDown",18,"DownArrow",40,"VK_DOWN","Down",e],[1,88,"ArrowUp",16,"UpArrow",38,"VK_UP","Up",e],[1,89,"NumLock",83,"NumLock",144,"VK_NUMLOCK",e,e],[1,90,"NumpadDivide",113,"NumPad_Divide",111,"VK_DIVIDE",e,e],[1,91,"NumpadMultiply",108,"NumPad_Multiply",106,"VK_MULTIPLY",e,e],[1,92,"NumpadSubtract",111,"NumPad_Subtract",109,"VK_SUBTRACT",e,e],[1,93,"NumpadAdd",109,"NumPad_Add",107,"VK_ADD",e,e],[1,94,"NumpadEnter",3,e,0,e,e,e],[1,95,"Numpad1",99,"NumPad1",97,"VK_NUMPAD1",e,e],[1,96,"Numpad2",100,"NumPad2",98,"VK_NUMPAD2",e,e],[1,97,"Numpad3",101,"NumPad3",99,"VK_NUMPAD3",e,e],[1,98,"Numpad4",102,"NumPad4",100,"VK_NUMPAD4",e,e],[1,99,"Numpad5",103,"NumPad5",101,"VK_NUMPAD5",e,e],[1,100,"Numpad6",104,"NumPad6",102,"VK_NUMPAD6",e,e],[1,101,"Numpad7",105,"NumPad7",103,"VK_NUMPAD7",e,e],[1,102,"Numpad8",106,"NumPad8",104,"VK_NUMPAD8",e,e],[1,103,"Numpad9",107,"NumPad9",105,"VK_NUMPAD9",e,e],[1,104,"Numpad0",98,"NumPad0",96,"VK_NUMPAD0",e,e],[1,105,"NumpadDecimal",112,"NumPad_Decimal",110,"VK_DECIMAL",e,e],[0,106,"IntlBackslash",97,"OEM_102",226,"VK_OEM_102",e,e],[1,107,"ContextMenu",58,"ContextMenu",93,e,e,e],[1,108,"Power",0,e,0,e,e,e],[1,109,"NumpadEqual",0,e,0,e,e,e],[1,110,"F13",71,"F13",124,"VK_F13",e,e],[1,111,"F14",72,"F14",125,"VK_F14",e,e],[1,112,"F15",73,"F15",126,"VK_F15",e,e],[1,113,"F16",74,"F16",127,"VK_F16",e,e],[1,114,"F17",75,"F17",128,"VK_F17",e,e],[1,115,"F18",76,"F18",129,"VK_F18",e,e],[1,116,"F19",77,"F19",130,"VK_F19",e,e],[1,117,"F20",78,"F20",131,"VK_F20",e,e],[1,118,"F21",79,"F21",132,"VK_F21",e,e],[1,119,"F22",80,"F22",133,"VK_F22",e,e],[1,120,"F23",81,"F23",134,"VK_F23",e,e],[1,121,"F24",82,"F24",135,"VK_F24",e,e],[1,122,"Open",0,e,0,e,e,e],[1,123,"Help",0,e,0,e,e,e],[1,124,"Select",0,e,0,e,e,e],[1,125,"Again",0,e,0,e,e,e],[1,126,"Undo",0,e,0,e,e,e],[1,127,"Cut",0,e,0,e,e,e],[1,128,"Copy",0,e,0,e,e,e],[1,129,"Paste",0,e,0,e,e,e],[1,130,"Find",0,e,0,e,e,e],[1,131,"AudioVolumeMute",117,"AudioVolumeMute",173,"VK_VOLUME_MUTE",e,e],[1,132,"AudioVolumeUp",118,"AudioVolumeUp",175,"VK_VOLUME_UP",e,e],[1,133,"AudioVolumeDown",119,"AudioVolumeDown",174,"VK_VOLUME_DOWN",e,e],[1,134,"NumpadComma",110,"NumPad_Separator",108,"VK_SEPARATOR",e,e],[0,135,"IntlRo",115,"ABNT_C1",193,"VK_ABNT_C1",e,e],[1,136,"KanaMode",0,e,0,e,e,e],[0,137,"IntlYen",0,e,0,e,e,e],[1,138,"Convert",0,e,0,e,e,e],[1,139,"NonConvert",0,e,0,e,e,e],[1,140,"Lang1",0,e,0,e,e,e],[1,141,"Lang2",0,e,0,e,e,e],[1,142,"Lang3",0,e,0,e,e,e],[1,143,"Lang4",0,e,0,e,e,e],[1,144,"Lang5",0,e,0,e,e,e],[1,145,"Abort",0,e,0,e,e,e],[1,146,"Props",0,e,0,e,e,e],[1,147,"NumpadParenLeft",0,e,0,e,e,e],[1,148,"NumpadParenRight",0,e,0,e,e,e],[1,149,"NumpadBackspace",0,e,0,e,e,e],[1,150,"NumpadMemoryStore",0,e,0,e,e,e],[1,151,"NumpadMemoryRecall",0,e,0,e,e,e],[1,152,"NumpadMemoryClear",0,e,0,e,e,e],[1,153,"NumpadMemoryAdd",0,e,0,e,e,e],[1,154,"NumpadMemorySubtract",0,e,0,e,e,e],[1,155,"NumpadClear",131,"Clear",12,"VK_CLEAR",e,e],[1,156,"NumpadClearEntry",0,e,0,e,e,e],[1,0,e,5,"Ctrl",17,"VK_CONTROL",e,e],[1,0,e,4,"Shift",16,"VK_SHIFT",e,e],[1,0,e,6,"Alt",18,"VK_MENU",e,e],[1,0,e,57,"Meta",91,"VK_COMMAND",e,e],[1,157,"ControlLeft",5,e,0,"VK_LCONTROL",e,e],[1,158,"ShiftLeft",4,e,0,"VK_LSHIFT",e,e],[1,159,"AltLeft",6,e,0,"VK_LMENU",e,e],[1,160,"MetaLeft",57,e,0,"VK_LWIN",e,e],[1,161,"ControlRight",5,e,0,"VK_RCONTROL",e,e],[1,162,"ShiftRight",4,e,0,"VK_RSHIFT",e,e],[1,163,"AltRight",6,e,0,"VK_RMENU",e,e],[1,164,"MetaRight",57,e,0,"VK_RWIN",e,e],[1,165,"BrightnessUp",0,e,0,e,e,e],[1,166,"BrightnessDown",0,e,0,e,e,e],[1,167,"MediaPlay",0,e,0,e,e,e],[1,168,"MediaRecord",0,e,0,e,e,e],[1,169,"MediaFastForward",0,e,0,e,e,e],[1,170,"MediaRewind",0,e,0,e,e,e],[1,171,"MediaTrackNext",124,"MediaTrackNext",176,"VK_MEDIA_NEXT_TRACK",e,e],[1,172,"MediaTrackPrevious",125,"MediaTrackPrevious",177,"VK_MEDIA_PREV_TRACK",e,e],[1,173,"MediaStop",126,"MediaStop",178,"VK_MEDIA_STOP",e,e],[1,174,"Eject",0,e,0,e,e,e],[1,175,"MediaPlayPause",127,"MediaPlayPause",179,"VK_MEDIA_PLAY_PAUSE",e,e],[1,176,"MediaSelect",128,"LaunchMediaPlayer",181,"VK_MEDIA_LAUNCH_MEDIA_SELECT",e,e],[1,177,"LaunchMail",129,"LaunchMail",180,"VK_MEDIA_LAUNCH_MAIL",e,e],[1,178,"LaunchApp2",130,"LaunchApp2",183,"VK_MEDIA_LAUNCH_APP2",e,e],[1,179,"LaunchApp1",0,e,0,"VK_MEDIA_LAUNCH_APP1",e,e],[1,180,"SelectTask",0,e,0,e,e,e],[1,181,"LaunchScreenSaver",0,e,0,e,e,e],[1,182,"BrowserSearch",120,"BrowserSearch",170,"VK_BROWSER_SEARCH",e,e],[1,183,"BrowserHome",121,"BrowserHome",172,"VK_BROWSER_HOME",e,e],[1,184,"BrowserBack",122,"BrowserBack",166,"VK_BROWSER_BACK",e,e],[1,185,"BrowserForward",123,"BrowserForward",167,"VK_BROWSER_FORWARD",e,e],[1,186,"BrowserStop",0,e,0,"VK_BROWSER_STOP",e,e],[1,187,"BrowserRefresh",0,e,0,"VK_BROWSER_REFRESH",e,e],[1,188,"BrowserFavorites",0,e,0,"VK_BROWSER_FAVORITES",e,e],[1,189,"ZoomToggle",0,e,0,e,e,e],[1,190,"MailReply",0,e,0,e,e,e],[1,191,"MailForward",0,e,0,e,e,e],[1,192,"MailSend",0,e,0,e,e,e],[1,0,e,114,"KeyInComposition",229,e,e,e],[1,0,e,116,"ABNT_C2",194,"VK_ABNT_C2",e,e],[1,0,e,96,"OEM_8",223,"VK_OEM_8",e,e],[1,0,e,0,e,0,"VK_KANA",e,e],[1,0,e,0,e,0,"VK_HANGUL",e,e],[1,0,e,0,e,0,"VK_JUNJA",e,e],[1,0,e,0,e,0,"VK_FINAL",e,e],[1,0,e,0,e,0,"VK_HANJA",e,e],[1,0,e,0,e,0,"VK_KANJI",e,e],[1,0,e,0,e,0,"VK_CONVERT",e,e],[1,0,e,0,e,0,"VK_NONCONVERT",e,e],[1,0,e,0,e,0,"VK_ACCEPT",e,e],[1,0,e,0,e,0,"VK_MODECHANGE",e,e],[1,0,e,0,e,0,"VK_SELECT",e,e],[1,0,e,0,e,0,"VK_PRINT",e,e],[1,0,e,0,e,0,"VK_EXECUTE",e,e],[1,0,e,0,e,0,"VK_SNAPSHOT",e,e],[1,0,e,0,e,0,"VK_HELP",e,e],[1,0,e,0,e,0,"VK_APPS",e,e],[1,0,e,0,e,0,"VK_PROCESSKEY",e,e],[1,0,e,0,e,0,"VK_PACKET",e,e],[1,0,e,0,e,0,"VK_DBE_SBCSCHAR",e,e],[1,0,e,0,e,0,"VK_DBE_DBCSCHAR",e,e],[1,0,e,0,e,0,"VK_ATTN",e,e],[1,0,e,0,e,0,"VK_CRSEL",e,e],[1,0,e,0,e,0,"VK_EXSEL",e,e],[1,0,e,0,e,0,"VK_EREOF",e,e],[1,0,e,0,e,0,"VK_PLAY",e,e],[1,0,e,0,e,0,"VK_ZOOM",e,e],[1,0,e,0,e,0,"VK_NONAME",e,e],[1,0,e,0,e,0,"VK_PA1",e,e],[1,0,e,0,e,0,"VK_OEM_CLEAR",e,e]],n=[],r=[];for(const i of t){const[e,t,s,p,b,_,k,v,C]=i;if(r[t]||(r[t]=!0,u[t]=s,d[s]=t,g[s.toLowerCase()]=t,e&&(f[t]=p,0!==p&&3!==p&&5!==p&&4!==p&&6!==p&&57!==p&&(m[p]=t))),!n[p]){if(n[p]=!0,!b)throw new Error(`String representation missing for key code ${p} around scan code ${s}`);o.define(p,b),a.define(p,v||b),l.define(p,C||v||b)}_&&(c[_]=p),k&&(h[k]=p)}m[3]=46}(),function(e){e.toString=function(e){return o.keyCodeToStr(e)},e.fromString=function(e){return o.strToKeyCode(e)},e.toUserSettingsUS=function(e){return a.keyCodeToStr(e)},e.toUserSettingsGeneral=function(e){return l.keyCodeToStr(e)},e.fromUserSettings=function(e){return a.strToKeyCode(e)||l.strToKeyCode(e)},e.toElectronAccelerator=function(e){if(e>=98&&e<=113)return null;switch(e){case 16:return"Up";case 18:return"Down";case 15:return"Left";case 17:return"Right"}return o.keyCodeToStr(e)}}(p||(p={}));var b,_,k,v,C,y,L,w,S,x,E,N,T,A,I,O,M,R,D,B,F,P,V,z,j,q,W,U,$,H,K,G,Q,J,X,Y,Z,ee,te,ne,re,ie,se,oe,ae,le,ce=n(9400),he=n(3069),ue=n(6677),de=n(5326),ge=n(2083);!function(e){e[e.Unknown=0]="Unknown",e[e.Disabled=1]="Disabled",e[e.Enabled=2]="Enabled"}(b||(b={})),function(e){e[e.Invoke=1]="Invoke",e[e.Auto=2]="Auto"}(_||(_={})),function(e){e[e.None=0]="None",e[e.KeepWhitespace=1]="KeepWhitespace",e[e.InsertAsSnippet=4]="InsertAsSnippet"}(k||(k={})),function(e){e[e.Method=0]="Method",e[e.Function=1]="Function",e[e.Constructor=2]="Constructor",e[e.Field=3]="Field",e[e.Variable=4]="Variable",e[e.Class=5]="Class",e[e.Struct=6]="Struct",e[e.Interface=7]="Interface",e[e.Module=8]="Module",e[e.Property=9]="Property",e[e.Event=10]="Event",e[e.Operator=11]="Operator",e[e.Unit=12]="Unit",e[e.Value=13]="Value",e[e.Constant=14]="Constant",e[e.Enum=15]="Enum",e[e.EnumMember=16]="EnumMember",e[e.Keyword=17]="Keyword",e[e.Text=18]="Text",e[e.Color=19]="Color",e[e.File=20]="File",e[e.Reference=21]="Reference",e[e.Customcolor=22]="Customcolor",e[e.Folder=23]="Folder",e[e.TypeParameter=24]="TypeParameter",e[e.User=25]="User",e[e.Issue=26]="Issue",e[e.Snippet=27]="Snippet"}(v||(v={})),function(e){e[e.Deprecated=1]="Deprecated"}(C||(C={})),function(e){e[e.Invoke=0]="Invoke",e[e.TriggerCharacter=1]="TriggerCharacter",e[e.TriggerForIncompleteCompletions=2]="TriggerForIncompleteCompletions"}(y||(y={})),function(e){e[e.EXACT=0]="EXACT",e[e.ABOVE=1]="ABOVE",e[e.BELOW=2]="BELOW"}(L||(L={})),function(e){e[e.NotSet=0]="NotSet",e[e.ContentFlush=1]="ContentFlush",e[e.RecoverFromMarkers=2]="RecoverFromMarkers",e[e.Explicit=3]="Explicit",e[e.Paste=4]="Paste",e[e.Undo=5]="Undo",e[e.Redo=6]="Redo"}(w||(w={})),function(e){e[e.LF=1]="LF",e[e.CRLF=2]="CRLF"}(S||(S={})),function(e){e[e.Text=0]="Text",e[e.Read=1]="Read",e[e.Write=2]="Write"}(x||(x={})),function(e){e[e.None=0]="None",e[e.Keep=1]="Keep",e[e.Brackets=2]="Brackets",e[e.Advanced=3]="Advanced",e[e.Full=4]="Full"}(E||(E={})),function(e){e[e.acceptSuggestionOnCommitCharacter=0]="acceptSuggestionOnCommitCharacter",e[e.acceptSuggestionOnEnter=1]="acceptSuggestionOnEnter",e[e.accessibilitySupport=2]="accessibilitySupport",e[e.accessibilityPageSize=3]="accessibilityPageSize",e[e.ariaLabel=4]="ariaLabel",e[e.ariaRequired=5]="ariaRequired",e[e.autoClosingBrackets=6]="autoClosingBrackets",e[e.autoClosingComments=7]="autoClosingComments",e[e.screenReaderAnnounceInlineSuggestion=8]="screenReaderAnnounceInlineSuggestion",e[e.autoClosingDelete=9]="autoClosingDelete",e[e.autoClosingOvertype=10]="autoClosingOvertype",e[e.autoClosingQuotes=11]="autoClosingQuotes",e[e.autoIndent=12]="autoIndent",e[e.automaticLayout=13]="automaticLayout",e[e.autoSurround=14]="autoSurround",e[e.bracketPairColorization=15]="bracketPairColorization",e[e.guides=16]="guides",e[e.codeLens=17]="codeLens",e[e.codeLensFontFamily=18]="codeLensFontFamily",e[e.codeLensFontSize=19]="codeLensFontSize",e[e.colorDecorators=20]="colorDecorators",e[e.colorDecoratorsLimit=21]="colorDecoratorsLimit",e[e.columnSelection=22]="columnSelection",e[e.comments=23]="comments",e[e.contextmenu=24]="contextmenu",e[e.copyWithSyntaxHighlighting=25]="copyWithSyntaxHighlighting",e[e.cursorBlinking=26]="cursorBlinking",e[e.cursorSmoothCaretAnimation=27]="cursorSmoothCaretAnimation",e[e.cursorStyle=28]="cursorStyle",e[e.cursorSurroundingLines=29]="cursorSurroundingLines",e[e.cursorSurroundingLinesStyle=30]="cursorSurroundingLinesStyle",e[e.cursorWidth=31]="cursorWidth",e[e.disableLayerHinting=32]="disableLayerHinting",e[e.disableMonospaceOptimizations=33]="disableMonospaceOptimizations",e[e.domReadOnly=34]="domReadOnly",e[e.dragAndDrop=35]="dragAndDrop",e[e.dropIntoEditor=36]="dropIntoEditor",e[e.emptySelectionClipboard=37]="emptySelectionClipboard",e[e.experimentalWhitespaceRendering=38]="experimentalWhitespaceRendering",e[e.extraEditorClassName=39]="extraEditorClassName",e[e.fastScrollSensitivity=40]="fastScrollSensitivity",e[e.find=41]="find",e[e.fixedOverflowWidgets=42]="fixedOverflowWidgets",e[e.folding=43]="folding",e[e.foldingStrategy=44]="foldingStrategy",e[e.foldingHighlight=45]="foldingHighlight",e[e.foldingImportsByDefault=46]="foldingImportsByDefault",e[e.foldingMaximumRegions=47]="foldingMaximumRegions",e[e.unfoldOnClickAfterEndOfLine=48]="unfoldOnClickAfterEndOfLine",e[e.fontFamily=49]="fontFamily",e[e.fontInfo=50]="fontInfo",e[e.fontLigatures=51]="fontLigatures",e[e.fontSize=52]="fontSize",e[e.fontWeight=53]="fontWeight",e[e.fontVariations=54]="fontVariations",e[e.formatOnPaste=55]="formatOnPaste",e[e.formatOnType=56]="formatOnType",e[e.glyphMargin=57]="glyphMargin",e[e.gotoLocation=58]="gotoLocation",e[e.hideCursorInOverviewRuler=59]="hideCursorInOverviewRuler",e[e.hover=60]="hover",e[e.inDiffEditor=61]="inDiffEditor",e[e.inlineSuggest=62]="inlineSuggest",e[e.inlineEdit=63]="inlineEdit",e[e.letterSpacing=64]="letterSpacing",e[e.lightbulb=65]="lightbulb",e[e.lineDecorationsWidth=66]="lineDecorationsWidth",e[e.lineHeight=67]="lineHeight",e[e.lineNumbers=68]="lineNumbers",e[e.lineNumbersMinChars=69]="lineNumbersMinChars",e[e.linkedEditing=70]="linkedEditing",e[e.links=71]="links",e[e.matchBrackets=72]="matchBrackets",e[e.minimap=73]="minimap",e[e.mouseStyle=74]="mouseStyle",e[e.mouseWheelScrollSensitivity=75]="mouseWheelScrollSensitivity",e[e.mouseWheelZoom=76]="mouseWheelZoom",e[e.multiCursorMergeOverlapping=77]="multiCursorMergeOverlapping",e[e.multiCursorModifier=78]="multiCursorModifier",e[e.multiCursorPaste=79]="multiCursorPaste",e[e.multiCursorLimit=80]="multiCursorLimit",e[e.occurrencesHighlight=81]="occurrencesHighlight",e[e.overviewRulerBorder=82]="overviewRulerBorder",e[e.overviewRulerLanes=83]="overviewRulerLanes",e[e.padding=84]="padding",e[e.pasteAs=85]="pasteAs",e[e.parameterHints=86]="parameterHints",e[e.peekWidgetDefaultFocus=87]="peekWidgetDefaultFocus",e[e.placeholder=88]="placeholder",e[e.definitionLinkOpensInPeek=89]="definitionLinkOpensInPeek",e[e.quickSuggestions=90]="quickSuggestions",e[e.quickSuggestionsDelay=91]="quickSuggestionsDelay",e[e.readOnly=92]="readOnly",e[e.readOnlyMessage=93]="readOnlyMessage",e[e.renameOnType=94]="renameOnType",e[e.renderControlCharacters=95]="renderControlCharacters",e[e.renderFinalNewline=96]="renderFinalNewline",e[e.renderLineHighlight=97]="renderLineHighlight",e[e.renderLineHighlightOnlyWhenFocus=98]="renderLineHighlightOnlyWhenFocus",e[e.renderValidationDecorations=99]="renderValidationDecorations",e[e.renderWhitespace=100]="renderWhitespace",e[e.revealHorizontalRightPadding=101]="revealHorizontalRightPadding",e[e.roundedSelection=102]="roundedSelection",e[e.rulers=103]="rulers",e[e.scrollbar=104]="scrollbar",e[e.scrollBeyondLastColumn=105]="scrollBeyondLastColumn",e[e.scrollBeyondLastLine=106]="scrollBeyondLastLine",e[e.scrollPredominantAxis=107]="scrollPredominantAxis",e[e.selectionClipboard=108]="selectionClipboard",e[e.selectionHighlight=109]="selectionHighlight",e[e.selectOnLineNumbers=110]="selectOnLineNumbers",e[e.showFoldingControls=111]="showFoldingControls",e[e.showUnused=112]="showUnused",e[e.snippetSuggestions=113]="snippetSuggestions",e[e.smartSelect=114]="smartSelect",e[e.smoothScrolling=115]="smoothScrolling",e[e.stickyScroll=116]="stickyScroll",e[e.stickyTabStops=117]="stickyTabStops",e[e.stopRenderingLineAfter=118]="stopRenderingLineAfter",e[e.suggest=119]="suggest",e[e.suggestFontSize=120]="suggestFontSize",e[e.suggestLineHeight=121]="suggestLineHeight",e[e.suggestOnTriggerCharacters=122]="suggestOnTriggerCharacters",e[e.suggestSelection=123]="suggestSelection",e[e.tabCompletion=124]="tabCompletion",e[e.tabIndex=125]="tabIndex",e[e.unicodeHighlighting=126]="unicodeHighlighting",e[e.unusualLineTerminators=127]="unusualLineTerminators",e[e.useShadowDOM=128]="useShadowDOM",e[e.useTabStops=129]="useTabStops",e[e.wordBreak=130]="wordBreak",e[e.wordSegmenterLocales=131]="wordSegmenterLocales",e[e.wordSeparators=132]="wordSeparators",e[e.wordWrap=133]="wordWrap",e[e.wordWrapBreakAfterCharacters=134]="wordWrapBreakAfterCharacters",e[e.wordWrapBreakBeforeCharacters=135]="wordWrapBreakBeforeCharacters",e[e.wordWrapColumn=136]="wordWrapColumn",e[e.wordWrapOverride1=137]="wordWrapOverride1",e[e.wordWrapOverride2=138]="wordWrapOverride2",e[e.wrappingIndent=139]="wrappingIndent",e[e.wrappingStrategy=140]="wrappingStrategy",e[e.showDeprecated=141]="showDeprecated",e[e.inlayHints=142]="inlayHints",e[e.editorClassName=143]="editorClassName",e[e.pixelRatio=144]="pixelRatio",e[e.tabFocusMode=145]="tabFocusMode",e[e.layoutInfo=146]="layoutInfo",e[e.wrappingInfo=147]="wrappingInfo",e[e.defaultColorDecorators=148]="defaultColorDecorators",e[e.colorDecoratorsActivatedOn=149]="colorDecoratorsActivatedOn",e[e.inlineCompletionsAccessibilityVerbose=150]="inlineCompletionsAccessibilityVerbose"}(N||(N={})),function(e){e[e.TextDefined=0]="TextDefined",e[e.LF=1]="LF",e[e.CRLF=2]="CRLF"}(T||(T={})),function(e){e[e.LF=0]="LF",e[e.CRLF=1]="CRLF"}(A||(A={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=3]="Right"}(I||(I={})),function(e){e[e.Increase=0]="Increase",e[e.Decrease=1]="Decrease"}(O||(O={})),function(e){e[e.None=0]="None",e[e.Indent=1]="Indent",e[e.IndentOutdent=2]="IndentOutdent",e[e.Outdent=3]="Outdent"}(M||(M={})),function(e){e[e.Both=0]="Both",e[e.Right=1]="Right",e[e.Left=2]="Left",e[e.None=3]="None"}(R||(R={})),function(e){e[e.Type=1]="Type",e[e.Parameter=2]="Parameter"}(D||(D={})),function(e){e[e.Automatic=0]="Automatic",e[e.Explicit=1]="Explicit"}(B||(B={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(F||(F={})),function(e){e[e.DependsOnKbLayout=-1]="DependsOnKbLayout",e[e.Unknown=0]="Unknown",e[e.Backspace=1]="Backspace",e[e.Tab=2]="Tab",e[e.Enter=3]="Enter",e[e.Shift=4]="Shift",e[e.Ctrl=5]="Ctrl",e[e.Alt=6]="Alt",e[e.PauseBreak=7]="PauseBreak",e[e.CapsLock=8]="CapsLock",e[e.Escape=9]="Escape",e[e.Space=10]="Space",e[e.PageUp=11]="PageUp",e[e.PageDown=12]="PageDown",e[e.End=13]="End",e[e.Home=14]="Home",e[e.LeftArrow=15]="LeftArrow",e[e.UpArrow=16]="UpArrow",e[e.RightArrow=17]="RightArrow",e[e.DownArrow=18]="DownArrow",e[e.Insert=19]="Insert",e[e.Delete=20]="Delete",e[e.Digit0=21]="Digit0",e[e.Digit1=22]="Digit1",e[e.Digit2=23]="Digit2",e[e.Digit3=24]="Digit3",e[e.Digit4=25]="Digit4",e[e.Digit5=26]="Digit5",e[e.Digit6=27]="Digit6",e[e.Digit7=28]="Digit7",e[e.Digit8=29]="Digit8",e[e.Digit9=30]="Digit9",e[e.KeyA=31]="KeyA",e[e.KeyB=32]="KeyB",e[e.KeyC=33]="KeyC",e[e.KeyD=34]="KeyD",e[e.KeyE=35]="KeyE",e[e.KeyF=36]="KeyF",e[e.KeyG=37]="KeyG",e[e.KeyH=38]="KeyH",e[e.KeyI=39]="KeyI",e[e.KeyJ=40]="KeyJ",e[e.KeyK=41]="KeyK",e[e.KeyL=42]="KeyL",e[e.KeyM=43]="KeyM",e[e.KeyN=44]="KeyN",e[e.KeyO=45]="KeyO",e[e.KeyP=46]="KeyP",e[e.KeyQ=47]="KeyQ",e[e.KeyR=48]="KeyR",e[e.KeyS=49]="KeyS",e[e.KeyT=50]="KeyT",e[e.KeyU=51]="KeyU",e[e.KeyV=52]="KeyV",e[e.KeyW=53]="KeyW",e[e.KeyX=54]="KeyX",e[e.KeyY=55]="KeyY",e[e.KeyZ=56]="KeyZ",e[e.Meta=57]="Meta",e[e.ContextMenu=58]="ContextMenu",e[e.F1=59]="F1",e[e.F2=60]="F2",e[e.F3=61]="F3",e[e.F4=62]="F4",e[e.F5=63]="F5",e[e.F6=64]="F6",e[e.F7=65]="F7",e[e.F8=66]="F8",e[e.F9=67]="F9",e[e.F10=68]="F10",e[e.F11=69]="F11",e[e.F12=70]="F12",e[e.F13=71]="F13",e[e.F14=72]="F14",e[e.F15=73]="F15",e[e.F16=74]="F16",e[e.F17=75]="F17",e[e.F18=76]="F18",e[e.F19=77]="F19",e[e.F20=78]="F20",e[e.F21=79]="F21",e[e.F22=80]="F22",e[e.F23=81]="F23",e[e.F24=82]="F24",e[e.NumLock=83]="NumLock",e[e.ScrollLock=84]="ScrollLock",e[e.Semicolon=85]="Semicolon",e[e.Equal=86]="Equal",e[e.Comma=87]="Comma",e[e.Minus=88]="Minus",e[e.Period=89]="Period",e[e.Slash=90]="Slash",e[e.Backquote=91]="Backquote",e[e.BracketLeft=92]="BracketLeft",e[e.Backslash=93]="Backslash",e[e.BracketRight=94]="BracketRight",e[e.Quote=95]="Quote",e[e.OEM_8=96]="OEM_8",e[e.IntlBackslash=97]="IntlBackslash",e[e.Numpad0=98]="Numpad0",e[e.Numpad1=99]="Numpad1",e[e.Numpad2=100]="Numpad2",e[e.Numpad3=101]="Numpad3",e[e.Numpad4=102]="Numpad4",e[e.Numpad5=103]="Numpad5",e[e.Numpad6=104]="Numpad6",e[e.Numpad7=105]="Numpad7",e[e.Numpad8=106]="Numpad8",e[e.Numpad9=107]="Numpad9",e[e.NumpadMultiply=108]="NumpadMultiply",e[e.NumpadAdd=109]="NumpadAdd",e[e.NUMPAD_SEPARATOR=110]="NUMPAD_SEPARATOR",e[e.NumpadSubtract=111]="NumpadSubtract",e[e.NumpadDecimal=112]="NumpadDecimal",e[e.NumpadDivide=113]="NumpadDivide",e[e.KEY_IN_COMPOSITION=114]="KEY_IN_COMPOSITION",e[e.ABNT_C1=115]="ABNT_C1",e[e.ABNT_C2=116]="ABNT_C2",e[e.AudioVolumeMute=117]="AudioVolumeMute",e[e.AudioVolumeUp=118]="AudioVolumeUp",e[e.AudioVolumeDown=119]="AudioVolumeDown",e[e.BrowserSearch=120]="BrowserSearch",e[e.BrowserHome=121]="BrowserHome",e[e.BrowserBack=122]="BrowserBack",e[e.BrowserForward=123]="BrowserForward",e[e.MediaTrackNext=124]="MediaTrackNext",e[e.MediaTrackPrevious=125]="MediaTrackPrevious",e[e.MediaStop=126]="MediaStop",e[e.MediaPlayPause=127]="MediaPlayPause",e[e.LaunchMediaPlayer=128]="LaunchMediaPlayer",e[e.LaunchMail=129]="LaunchMail",e[e.LaunchApp2=130]="LaunchApp2",e[e.Clear=131]="Clear",e[e.MAX_VALUE=132]="MAX_VALUE"}(P||(P={})),function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(V||(V={})),function(e){e[e.Unnecessary=1]="Unnecessary",e[e.Deprecated=2]="Deprecated"}(z||(z={})),function(e){e[e.Inline=1]="Inline",e[e.Gutter=2]="Gutter"}(j||(j={})),function(e){e[e.Normal=1]="Normal",e[e.Underlined=2]="Underlined"}(q||(q={})),function(e){e[e.UNKNOWN=0]="UNKNOWN",e[e.TEXTAREA=1]="TEXTAREA",e[e.GUTTER_GLYPH_MARGIN=2]="GUTTER_GLYPH_MARGIN",e[e.GUTTER_LINE_NUMBERS=3]="GUTTER_LINE_NUMBERS",e[e.GUTTER_LINE_DECORATIONS=4]="GUTTER_LINE_DECORATIONS",e[e.GUTTER_VIEW_ZONE=5]="GUTTER_VIEW_ZONE",e[e.CONTENT_TEXT=6]="CONTENT_TEXT",e[e.CONTENT_EMPTY=7]="CONTENT_EMPTY",e[e.CONTENT_VIEW_ZONE=8]="CONTENT_VIEW_ZONE",e[e.CONTENT_WIDGET=9]="CONTENT_WIDGET",e[e.OVERVIEW_RULER=10]="OVERVIEW_RULER",e[e.SCROLLBAR=11]="SCROLLBAR",e[e.OVERLAY_WIDGET=12]="OVERLAY_WIDGET",e[e.OUTSIDE_EDITOR=13]="OUTSIDE_EDITOR"}(W||(W={})),function(e){e[e.AIGenerated=1]="AIGenerated"}(U||(U={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}($||($={})),function(e){e[e.TOP_RIGHT_CORNER=0]="TOP_RIGHT_CORNER",e[e.BOTTOM_RIGHT_CORNER=1]="BOTTOM_RIGHT_CORNER",e[e.TOP_CENTER=2]="TOP_CENTER"}(H||(H={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=4]="Right",e[e.Full=7]="Full"}(K||(K={})),function(e){e[e.Word=0]="Word",e[e.Line=1]="Line",e[e.Suggest=2]="Suggest"}(G||(G={})),function(e){e[e.Left=0]="Left",e[e.Right=1]="Right",e[e.None=2]="None",e[e.LeftOfInjectedText=3]="LeftOfInjectedText",e[e.RightOfInjectedText=4]="RightOfInjectedText"}(Q||(Q={})),function(e){e[e.Off=0]="Off",e[e.On=1]="On",e[e.Relative=2]="Relative",e[e.Interval=3]="Interval",e[e.Custom=4]="Custom"}(J||(J={})),function(e){e[e.None=0]="None",e[e.Text=1]="Text",e[e.Blocks=2]="Blocks"}(X||(X={})),function(e){e[e.Smooth=0]="Smooth",e[e.Immediate=1]="Immediate"}(Y||(Y={})),function(e){e[e.Auto=1]="Auto",e[e.Hidden=2]="Hidden",e[e.Visible=3]="Visible"}(Z||(Z={})),function(e){e[e.LTR=0]="LTR",e[e.RTL=1]="RTL"}(ee||(ee={})),function(e){e.Off="off",e.OnCode="onCode",e.On="on"}(te||(te={})),function(e){e[e.Invoke=1]="Invoke",e[e.TriggerCharacter=2]="TriggerCharacter",e[e.ContentChange=3]="ContentChange"}(ne||(ne={})),function(e){e[e.File=0]="File",e[e.Module=1]="Module",e[e.Namespace=2]="Namespace",e[e.Package=3]="Package",e[e.Class=4]="Class",e[e.Method=5]="Method",e[e.Property=6]="Property",e[e.Field=7]="Field",e[e.Constructor=8]="Constructor",e[e.Enum=9]="Enum",e[e.Interface=10]="Interface",e[e.Function=11]="Function",e[e.Variable=12]="Variable",e[e.Constant=13]="Constant",e[e.String=14]="String",e[e.Number=15]="Number",e[e.Boolean=16]="Boolean",e[e.Array=17]="Array",e[e.Object=18]="Object",e[e.Key=19]="Key",e[e.Null=20]="Null",e[e.EnumMember=21]="EnumMember",e[e.Struct=22]="Struct",e[e.Event=23]="Event",e[e.Operator=24]="Operator",e[e.TypeParameter=25]="TypeParameter"}(re||(re={})),function(e){e[e.Deprecated=1]="Deprecated"}(ie||(ie={})),function(e){e[e.Hidden=0]="Hidden",e[e.Blink=1]="Blink",e[e.Smooth=2]="Smooth",e[e.Phase=3]="Phase",e[e.Expand=4]="Expand",e[e.Solid=5]="Solid"}(se||(se={})),function(e){e[e.Line=1]="Line",e[e.Block=2]="Block",e[e.Underline=3]="Underline",e[e.LineThin=4]="LineThin",e[e.BlockOutline=5]="BlockOutline",e[e.UnderlineThin=6]="UnderlineThin"}(oe||(oe={})),function(e){e[e.AlwaysGrowsWhenTypingAtEdges=0]="AlwaysGrowsWhenTypingAtEdges",e[e.NeverGrowsWhenTypingAtEdges=1]="NeverGrowsWhenTypingAtEdges",e[e.GrowsOnlyWhenTypingBefore=2]="GrowsOnlyWhenTypingBefore",e[e.GrowsOnlyWhenTypingAfter=3]="GrowsOnlyWhenTypingAfter"}(ae||(ae={})),function(e){e[e.None=0]="None",e[e.Same=1]="Same",e[e.Indent=2]="Indent",e[e.DeepIndent=3]="DeepIndent"}(le||(le={}));class fe{static{this.CtrlCmd=2048}static{this.Shift=1024}static{this.Alt=512}static{this.WinCtrl=256}static chord(e,t){return function(e,t){return(e|(65535&t)<<16>>>0)>>>0}(e,t)}}function me(){return{editor:void 0,languages:void 0,CancellationTokenSource:r.Qi,Emitter:i.vl,KeyCode:P,KeyMod:fe,Position:he.y,Range:ue.Q,Selection:de.L,SelectionDirection:ee,MarkerSeverity:V,MarkerTag:z,Uri:ce.r,Token:ge.ou}}},4320:(e,t,n)=>{"use strict";var r,i;n.d(t,{cO:()=>h,db:()=>u,fT:()=>o,qK:()=>c});class s{constructor(e,t){this.uri=e,this.value=t}}class o{static{this.defaultToKey=e=>e.toString()}constructor(e,t){if(this[r]="ResourceMap",e instanceof o)this.map=new Map(e.map),this.toKey=t??o.defaultToKey;else if(function(e){return Array.isArray(e)}(e)){this.map=new Map,this.toKey=t??o.defaultToKey;for(const[t,n]of e)this.set(t,n)}else this.map=new Map,this.toKey=e??o.defaultToKey}set(e,t){return this.map.set(this.toKey(e),new s(e,t)),this}get(e){return this.map.get(this.toKey(e))?.value}has(e){return this.map.has(this.toKey(e))}get size(){return this.map.size}clear(){this.map.clear()}delete(e){return this.map.delete(this.toKey(e))}forEach(e,t){"undefined"!==typeof t&&(e=e.bind(t));for(const[n,r]of this.map)e(r.value,r.uri,this)}*values(){for(const e of this.map.values())yield e.value}*keys(){for(const e of this.map.values())yield e.uri}*entries(){for(const e of this.map.values())yield[e.uri,e.value]}*[(r=Symbol.toStringTag,Symbol.iterator)](){for(const[,e]of this.map)yield[e.uri,e.value]}}class a{constructor(){this[i]="LinkedMap",this._map=new Map,this._head=void 0,this._tail=void 0,this._size=0,this._state=0}clear(){this._map.clear(),this._head=void 0,this._tail=void 0,this._size=0,this._state++}isEmpty(){return!this._head&&!this._tail}get size(){return this._size}get first(){return this._head?.value}get last(){return this._tail?.value}has(e){return this._map.has(e)}get(e,t=0){const n=this._map.get(e);if(n)return 0!==t&&this.touch(n,t),n.value}set(e,t,n=0){let r=this._map.get(e);if(r)r.value=t,0!==n&&this.touch(r,n);else{switch(r={key:e,value:t,next:void 0,previous:void 0},n){case 0:case 2:default:this.addItemLast(r);break;case 1:this.addItemFirst(r)}this._map.set(e,r),this._size++}return this}delete(e){return!!this.remove(e)}remove(e){const t=this._map.get(e);if(t)return this._map.delete(e),this.removeItem(t),this._size--,t.value}shift(){if(!this._head&&!this._tail)return;if(!this._head||!this._tail)throw new Error("Invalid list");const e=this._head;return this._map.delete(e.key),this.removeItem(e),this._size--,e.value}forEach(e,t){const n=this._state;let r=this._head;for(;r;){if(t?e.bind(t)(r.value,r.key,this):e(r.value,r.key,this),this._state!==n)throw new Error("LinkedMap got modified during iteration.");r=r.next}}keys(){const e=this,t=this._state;let n=this._head;const r={[Symbol.iterator]:()=>r,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(n){const e={value:n.key,done:!1};return n=n.next,e}return{value:void 0,done:!0}}};return r}values(){const e=this,t=this._state;let n=this._head;const r={[Symbol.iterator]:()=>r,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(n){const e={value:n.value,done:!1};return n=n.next,e}return{value:void 0,done:!0}}};return r}entries(){const e=this,t=this._state;let n=this._head;const r={[Symbol.iterator]:()=>r,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(n){const e={value:[n.key,n.value],done:!1};return n=n.next,e}return{value:void 0,done:!0}}};return r}[(i=Symbol.toStringTag,Symbol.iterator)](){return this.entries()}trimOld(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._head,n=this.size;for(;t&&n>e;)this._map.delete(t.key),t=t.next,n--;this._head=t,this._size=n,t&&(t.previous=void 0),this._state++}trimNew(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._tail,n=this.size;for(;t&&n>e;)this._map.delete(t.key),t=t.previous,n--;this._tail=t,this._size=n,t&&(t.next=void 0),this._state++}addItemFirst(e){if(this._head||this._tail){if(!this._head)throw new Error("Invalid list");e.next=this._head,this._head.previous=e}else this._tail=e;this._head=e,this._state++}addItemLast(e){if(this._head||this._tail){if(!this._tail)throw new Error("Invalid list");e.previous=this._tail,this._tail.next=e}else this._head=e;this._tail=e,this._state++}removeItem(e){if(e===this._head&&e===this._tail)this._head=void 0,this._tail=void 0;else if(e===this._head){if(!e.next)throw new Error("Invalid list");e.next.previous=void 0,this._head=e.next}else if(e===this._tail){if(!e.previous)throw new Error("Invalid list");e.previous.next=void 0,this._tail=e.previous}else{const t=e.next,n=e.previous;if(!t||!n)throw new Error("Invalid list");t.previous=n,n.next=t}e.next=void 0,e.previous=void 0,this._state++}touch(e,t){if(!this._head||!this._tail)throw new Error("Invalid list");if(1===t||2===t)if(1===t){if(e===this._head)return;const t=e.next,n=e.previous;e===this._tail?(n.next=void 0,this._tail=n):(t.previous=n,n.next=t),e.previous=void 0,e.next=this._head,this._head.previous=e,this._head=e,this._state++}else if(2===t){if(e===this._tail)return;const t=e.next,n=e.previous;e===this._head?(t.previous=void 0,this._head=t):(t.previous=n,n.next=t),e.next=void 0,e.previous=this._tail,this._tail.next=e,this._tail=e,this._state++}}toJSON(){const e=[];return this.forEach(((t,n)=>{e.push([n,t])})),e}fromJSON(e){this.clear();for(const[t,n]of e)this.set(t,n)}}class l extends a{constructor(e,t=1){super(),this._limit=e,this._ratio=Math.min(Math.max(0,t),1)}get limit(){return this._limit}set limit(e){this._limit=e,this.checkTrim()}get(e,t=2){return super.get(e,t)}peek(e){return super.get(e,0)}set(e,t){return super.set(e,t,2),this}checkTrim(){this.size>this._limit&&this.trim(Math.round(this._limit*this._ratio))}}class c extends l{constructor(e,t=1){super(e,t)}trim(e){this.trimOld(e)}set(e,t){return super.set(e,t),this.checkTrim(),this}}class h{constructor(e){if(this._m1=new Map,this._m2=new Map,e)for(const[t,n]of e)this.set(t,n)}clear(){this._m1.clear(),this._m2.clear()}set(e,t){this._m1.set(e,t),this._m2.set(t,e)}get(e){return this._m1.get(e)}getKey(e){return this._m2.get(e)}delete(e){const t=this._m1.get(e);return void 0!==t&&(this._m1.delete(e),this._m2.delete(t),!0)}keys(){return this._m1.keys()}values(){return this._m1.values()}}class u{constructor(){this.map=new Map}add(e,t){let n=this.map.get(e);n||(n=new Set,this.map.set(e,n)),n.add(t)}delete(e,t){const n=this.map.get(e);n&&(n.delete(t),0===n.size&&this.map.delete(e))}forEach(e,t){const n=this.map.get(e);n&&n.forEach(t)}get(e){const t=this.map.get(e);return t||new Set}}},4383:(e,t,n)=>{"use strict";n.d(t,{D7:()=>g,EM:()=>u,Qg:()=>c,cU:()=>s,dz:()=>i,iH:()=>h});const r=new class{constructor(){this.listeners=[],this.unexpectedErrorHandler=function(e){setTimeout((()=>{if(e.stack){if(d.isErrorNoTelemetry(e))throw new d(e.message+"\n\n"+e.stack);throw new Error(e.message+"\n\n"+e.stack)}throw e}),0)}}emit(e){this.listeners.forEach((t=>{t(e)}))}onUnexpectedError(e){this.unexpectedErrorHandler(e),this.emit(e)}onUnexpectedExternalError(e){this.unexpectedErrorHandler(e)}};function i(e){a(e)||r.onUnexpectedError(e)}function s(e){if(e instanceof Error){const{name:t,message:n}=e;return{$isError:!0,name:t,message:n,stack:e.stacktrace||e.stack,noTelemetry:d.isErrorNoTelemetry(e)}}return e}const o="Canceled";function a(e){return e instanceof l||e instanceof Error&&e.name===o&&e.message===o}class l extends Error{constructor(){super(o),this.name=this.message}}function c(e){return e?new Error(`Illegal argument: ${e}`):new Error("Illegal argument")}function h(e){return e?new Error(`Illegal state: ${e}`):new Error("Illegal state")}class u extends Error{constructor(e){super("NotSupported"),e&&(this.message=e)}}class d extends Error{constructor(e){super(e),this.name="CodeExpectedError"}static fromError(e){if(e instanceof d)return e;const t=new d;return t.message=e.message,t.stack=e.stack,t}static isErrorNoTelemetry(e){return"CodeExpectedError"===e.name}}class g extends Error{constructor(e){super(e||"An unexpected bug occurred."),Object.setPrototypeOf(this,g.prototype)}}},4432:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITreeSitterParserService:()=>r});const r=(0,n(3591).u1)("treeSitterParserService")},4444:(e,t,n)=>{"use strict";n.d(t,{L:()=>i});var r=n(4383);class i{static addRange(e,t){let n=0;for(;nt))return new i(e,t)}static ofLength(e){return new i(0,e)}static ofStartAndLength(e,t){return new i(e,e+t)}constructor(e,t){if(this.start=e,this.endExclusive=t,e>t)throw new r.D7(`Invalid range: ${this.toString()}`)}get isEmpty(){return this.start===this.endExclusive}delta(e){return new i(this.start+e,this.endExclusive+e)}deltaStart(e){return new i(this.start+e,this.endExclusive)}deltaEnd(e){return new i(this.start,this.endExclusive+e)}get length(){return this.endExclusive-this.start}toString(){return`[${this.start}, ${this.endExclusive})`}contains(e){return this.start<=e&&e=e.endExclusive}slice(e){return e.slice(this.start,this.endExclusive)}substring(e){return e.substring(this.start,this.endExclusive)}clip(e){if(this.isEmpty)throw new r.D7(`Invalid clipping range: ${this.toString()}`);return Math.max(this.start,Math.min(this.endExclusive-1,e))}clipCyclic(e){if(this.isEmpty)throw new r.D7(`Invalid clipping range: ${this.toString()}`);return e=this.endExclusive?this.start+(e-this.start)%this.length:e}forEach(e){for(let t=this.start;t{"use strict";function r(e){let t=0,n=0,r=0,i=0;for(let s=0,o=e.length;sr})},4621:(e,t,n)=>{"use strict";n.d(t,{v:()=>s});class r{constructor(e,t=[],n=!1){this.ctor=e,this.staticArguments=t,this.supportsDelayedInstantiation=n}}const i=[];function s(e,t,n){t instanceof r||(t=new r(t,[],Boolean(n))),i.push([e,t])}},4855:(e,t,n)=>{"use strict";n.r(t),n.d(t,{UnicodeTextModelHighlighter:()=>l});var r=n(6677),i=n(7729),s=n(1508),o=n(6782),a=n(6486);class l{static computeUnicodeHighlights(e,t,n){const l=n?n.startLineNumber:1,h=n?n.endLineNumber:e.getLineCount(),u=new c(t),d=u.getCandidateCodePoints();let g;var f;g="allNonBasicAscii"===d?new RegExp("[^\\t\\n\\r\\x20-\\x7E]","g"):new RegExp(""+(f=Array.from(d),`[${s.bm(f.map((e=>String.fromCodePoint(e))).join(""))}]`),"g");const m=new i.W5(null,g),p=[];let b,_=!1,k=0,v=0,C=0;e:for(let i=l,c=h;i<=c;i++){const t=e.getLineContent(i),n=t.length;m.reset(0);do{if(b=m.next(t),b){let e=b.index,l=b.index+b[0].length;if(e>0){const n=t.charCodeAt(e-1);s.pc(n)&&e--}if(l+1=t){_=!0;break e}p.push(new r.Q(i,e+1,i,l+1))}}}while(b)}return{ranges:p,hasMore:_,ambiguousCharacterCount:k,invisibleCharacterCount:v,nonBasicAsciiCharacterCount:C}}static computeUnicodeHighlightReason(e,t){const n=new c(t);switch(n.shouldHighlightNonBasicASCII(e,null)){case 0:return null;case 2:return{kind:1};case 3:{const r=e.codePointAt(0),i=n.ambiguousCharacters.getPrimaryConfusable(r),o=s.tl.getLocales().filter((e=>!s.tl.getInstance(new Set([...t.allowedLocales,e])).isAmbiguous(r)));return{kind:0,confusableWith:String.fromCodePoint(i),notAmbiguousInLocales:o}}case 1:return{kind:2}}}}class c{constructor(e){this.options=e,this.allowedCodePoints=new Set(e.allowedCodePoints),this.ambiguousCharacters=s.tl.getInstance(new Set(e.allowedLocales))}getCandidateCodePoints(){if(this.options.nonBasicASCII)return"allNonBasicAscii";const e=new Set;if(this.options.invisibleCharacters)for(const t of s.y_.codePoints)h(String.fromCodePoint(t))||e.add(t);if(this.options.ambiguousCharacters)for(const t of this.ambiguousCharacters.getConfusableCodePoints())e.add(t);for(const t of this.allowedCodePoints)e.delete(t);return e}shouldHighlightNonBasicASCII(e,t){const n=e.codePointAt(0);if(this.allowedCodePoints.has(n))return 0;if(this.options.nonBasicASCII)return 1;let r=!1,i=!1;if(t)for(const o of t){const e=o.codePointAt(0),t=s.aC(o);r=r||t,t||this.ambiguousCharacters.isAmbiguous(e)||s.y_.isInvisibleCharacter(e)||(i=!0)}return!r&&i?0:this.options.invisibleCharacters&&!h(e)&&s.y_.isInvisibleCharacter(n)?2:this.options.ambiguousCharacters&&this.ambiguousCharacters.isAmbiguous(n)?3:0}}function h(e){return" "===e||"\n"===e||"\t"===e}},5152:(e,t,n)=>{"use strict";function r(e){return e<0?0:e>255?255:0|e}function i(e){return e<0?0:e>4294967295?4294967295:0|e}n.d(t,{W:()=>r,j:()=>i})},5196:(e,t,n)=>{"use strict";n.r(t),n.d(t,{BaseEditorSimpleWorker:()=>Pe,EditorSimpleWorker:()=>Ve,create:()=>ze});class r{constructor(e,t,n,r){this.originalStart=e,this.originalLength=t,this.modifiedStart=n,this.modifiedLength=r}getOriginalEnd(){return this.originalStart+this.originalLength}getModifiedEnd(){return this.modifiedStart+this.modifiedLength}}var i=n(5600);class s{constructor(e){this.source=e}getElements(){const e=this.source,t=new Int32Array(e.length);for(let n=0,r=e.length;n0||this.m_modifiedCount>0)&&this.m_changes.push(new r(this.m_originalStart,this.m_originalCount,this.m_modifiedStart,this.m_modifiedCount)),this.m_originalCount=0,this.m_modifiedCount=0,this.m_originalStart=1073741824,this.m_modifiedStart=1073741824}AddOriginalElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_originalCount++}AddModifiedElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_modifiedCount++}getChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes}getReverseChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes.reverse(),this.m_changes}}class h{constructor(e,t,n=null){this.ContinueProcessingPredicate=n,this._originalSequence=e,this._modifiedSequence=t;const[r,i,s]=h._getElements(e),[o,a,l]=h._getElements(t);this._hasStrings=s&&l,this._originalStringElements=r,this._originalElementsOrHash=i,this._modifiedStringElements=o,this._modifiedElementsOrHash=a,this.m_forwardHistory=[],this.m_reverseHistory=[]}static _isStringArray(e){return e.length>0&&"string"===typeof e[0]}static _getElements(e){const t=e.getElements();if(h._isStringArray(t)){const e=new Int32Array(t.length);for(let n=0,r=t.length;n=e&&i>=n&&this.ElementsAreEqual(t,i);)t--,i--;if(e>t||n>i){let s;return n<=i?(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),s=[new r(e,0,n,i-n+1)]):e<=t?(a.Assert(n===i+1,"modifiedStart should only be one more than modifiedEnd"),s=[new r(e,t-e+1,n,0)]):(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),a.Assert(n===i+1,"modifiedStart should only be one more than modifiedEnd"),s=[]),s}const o=[0],l=[0],c=this.ComputeRecursionPoint(e,t,n,i,o,l,s),h=o[0],u=l[0];if(null!==c)return c;if(!s[0]){const o=this.ComputeDiffRecursive(e,h,n,u,s);let a=[];return a=s[0]?[new r(h+1,t-(h+1)+1,u+1,i-(u+1)+1)]:this.ComputeDiffRecursive(h+1,t,u+1,i,s),this.ConcatenateChanges(o,a)}return[new r(e,t-e+1,n,i-n+1)]}WALKTRACE(e,t,n,i,s,o,a,l,h,u,d,g,f,m,p,b,_,k){let v=null,C=null,y=new c,L=t,w=n,S=f[0]-b[0]-i,x=-1073741824,E=this.m_forwardHistory.length-1;do{const t=S+e;t===L||t=0&&(e=(h=this.m_forwardHistory[E])[0],L=1,w=h.length-1)}while(--E>=-1);if(v=y.getReverseChanges(),k[0]){let e=f[0]+1,t=b[0]+1;if(null!==v&&v.length>0){const n=v[v.length-1];e=Math.max(e,n.getOriginalEnd()),t=Math.max(t,n.getModifiedEnd())}C=[new r(e,g-e+1,t,p-t+1)]}else{y=new c,L=o,w=a,S=f[0]-b[0]-l,x=1073741824,E=_?this.m_reverseHistory.length-1:this.m_reverseHistory.length-2;do{const e=S+s;e===L||e=u[e+1]?(m=(d=u[e+1]-1)-S-l,d>x&&y.MarkNextChange(),x=d+1,y.AddOriginalElement(d+1,m+1),S=e+1-s):(m=(d=u[e-1])-S-l,d>x&&y.MarkNextChange(),x=d,y.AddModifiedElement(d+1,m+1),S=e-1-s),E>=0&&(s=(u=this.m_reverseHistory[E])[0],L=1,w=u.length-1)}while(--E>=-1);C=y.getChanges()}return this.ConcatenateChanges(v,C)}ComputeRecursionPoint(e,t,n,i,s,o,a){let c=0,h=0,u=0,d=0,g=0,f=0;e--,n--,s[0]=0,o[0]=0,this.m_forwardHistory=[],this.m_reverseHistory=[];const m=t-e+(i-n),p=m+1,b=new Int32Array(p),_=new Int32Array(p),k=i-n,v=t-e,C=e-n,y=t-i,L=(v-k)%2===0;b[k]=e,_[v]=t,a[0]=!1;for(let w=1;w<=m/2+1;w++){let m=0,S=0;u=this.ClipDiagonalBound(k-w,w,k,p),d=this.ClipDiagonalBound(k+w,w,k,p);for(let e=u;e<=d;e+=2){c=e===u||em+S&&(m=c,S=h),!L&&Math.abs(e-v)<=w-1&&c>=_[e])return s[0]=c,o[0]=h,n<=_[e]&&w<=1448?this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a):null}const x=(m-e+(S-n)-w)/2;if(null!==this.ContinueProcessingPredicate&&!this.ContinueProcessingPredicate(m,x))return a[0]=!0,s[0]=m,o[0]=S,x>0&&w<=1448?this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a):(e++,n++,[new r(e,t-e+1,n,i-n+1)]);g=this.ClipDiagonalBound(v-w,w,v,p),f=this.ClipDiagonalBound(v+w,w,v,p);for(let r=g;r<=f;r+=2){c=r===g||r=_[r+1]?_[r+1]-1:_[r-1],h=c-(r-v)-y;const l=c;for(;c>e&&h>n&&this.ElementsAreEqual(c,h);)c--,h--;if(_[r]=c,L&&Math.abs(r-k)<=w&&c<=b[r])return s[0]=c,o[0]=h,l>=b[r]&&w<=1448?this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a):null}if(w<=1447){let e=new Int32Array(d-u+2);e[0]=k-u+1,l.Copy2(b,u,e,1,d-u+1),this.m_forwardHistory.push(e),e=new Int32Array(f-g+2),e[0]=v-g+1,l.Copy2(_,g,e,1,f-g+1),this.m_reverseHistory.push(e)}}return this.WALKTRACE(k,u,d,C,v,g,f,y,b,_,c,t,s,h,i,o,L,a)}PrettifyChanges(e){for(let t=0;t0,o=n.modifiedLength>0;for(;n.originalStart+n.originalLength=0;t--){const n=e[t];let r=0,i=0;if(t>0){const n=e[t-1];r=n.originalStart+n.originalLength,i=n.modifiedStart+n.modifiedLength}const s=n.originalLength>0,o=n.modifiedLength>0;let a=0,l=this._boundaryScore(n.originalStart,n.originalLength,n.modifiedStart,n.modifiedLength);for(let e=1;;e++){const t=n.originalStart-e,c=n.modifiedStart-e;if(tl&&(l=h,a=e)}n.originalStart-=a,n.modifiedStart-=a;const c=[null];t>0&&this.ChangesOverlap(e[t-1],e[t],c)&&(e[t-1]=c[0],e.splice(t,1),t++)}if(this._hasStrings)for(let t=1,n=e.length;t0&&t>a&&(a=t,l=h,c=e)}return a>0?[l,c]:null}_contiguousSequenceScore(e,t,n){let r=0;for(let i=0;i=this._originalElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._originalStringElements[e])}_OriginalRegionIsBoundary(e,t){if(this._OriginalIsBoundary(e)||this._OriginalIsBoundary(e-1))return!0;if(t>0){const n=e+t;if(this._OriginalIsBoundary(n-1)||this._OriginalIsBoundary(n))return!0}return!1}_ModifiedIsBoundary(e){return e<=0||e>=this._modifiedElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._modifiedStringElements[e])}_ModifiedRegionIsBoundary(e,t){if(this._ModifiedIsBoundary(e)||this._ModifiedIsBoundary(e-1))return!0;if(t>0){const n=e+t;if(this._ModifiedIsBoundary(n-1)||this._ModifiedIsBoundary(n))return!0}return!1}_boundaryScore(e,t,n,r){return(this._OriginalRegionIsBoundary(e,t)?1:0)+(this._ModifiedRegionIsBoundary(n,r)?1:0)}ConcatenateChanges(e,t){const n=[];if(0===e.length||0===t.length)return t.length>0?t:e;if(this.ChangesOverlap(e[e.length-1],t[0],n)){const r=new Array(e.length+t.length-1);return l.Copy(e,0,r,0,e.length-1),r[e.length-1]=n[0],l.Copy(t,1,r,e.length,t.length-1),r}{const n=new Array(e.length+t.length);return l.Copy(e,0,n,0,e.length),l.Copy(t,0,n,e.length,t.length),n}}ChangesOverlap(e,t,n){if(a.Assert(e.originalStart<=t.originalStart,"Left change is not less than or equal to right change"),a.Assert(e.modifiedStart<=t.modifiedStart,"Left change is not less than or equal to right change"),e.originalStart+e.originalLength>=t.originalStart||e.modifiedStart+e.modifiedLength>=t.modifiedStart){const i=e.originalStart;let s=e.originalLength;const o=e.modifiedStart;let a=e.modifiedLength;return e.originalStart+e.originalLength>=t.originalStart&&(s=t.originalStart+t.originalLength-e.originalStart),e.modifiedStart+e.modifiedLength>=t.modifiedStart&&(a=t.modifiedStart+t.modifiedLength-e.modifiedStart),n[0]=new r(i,s,o,a),!0}return n[0]=null,!1}ClipDiagonalBound(e,t,n,r){if(e>=0&&et&&(t=s),r>n&&(n=r),o>n&&(n=o)}t++,n++;const r=new g(n,t,0);for(let i=0,s=e.length;i=this._maxCharCode?0:this._states.get(e,t)}}let m=null;let p=null;class b{static _createLink(e,t,n,r,i){let s=i-1;do{const n=t.charCodeAt(s);if(2!==e.get(n))break;s--}while(s>r);if(r>0){const e=t.charCodeAt(r-1),n=t.charCodeAt(s);(40===e&&41===n||91===e&&93===n||123===e&&125===n)&&s--}return{range:{startLineNumber:n,startColumn:r+1,endLineNumber:n,endColumn:s+2},url:t.substring(r,s+1)}}static computeLinks(e,t=function(){return null===m&&(m=new f([[1,104,2],[1,72,2],[1,102,6],[1,70,6],[2,116,3],[2,84,3],[3,116,4],[3,84,4],[4,112,5],[4,80,5],[5,115,9],[5,83,9],[5,58,10],[6,105,7],[6,73,7],[7,108,8],[7,76,8],[8,101,9],[8,69,9],[9,58,10],[10,47,11],[11,47,12]])),m}()){const n=function(){if(null===p){p=new d.V(0);const e=" \t<>'\"\u3001\u3002\uff61\uff64\uff0c\uff0e\uff1a\uff1b\u2018\u3008\u300c\u300e\u3014\uff08\uff3b\uff5b\uff62\uff63\uff5d\uff3d\uff09\u3015\u300f\u300d\u3009\u2019\uff40\uff5e\u2026";for(let n=0;n=0?(r+=n?1:-1,r<0?r=e.length-1:r%=e.length,e[r]):null}}var k=n(4272),v=n(718),C=n(8381),y=n(4855);class L{constructor(e,t,n){this.changes=e,this.moves=t,this.hitTimeout=n}}class w{constructor(e,t){this.lineRangeMapping=e,this.changes=t}}var S=n(4383),x=n(6571),E=n(3069),N=n(6782),T=n(4444);n(973);class A{constructor(e,t){this.range=e,this.text=t}toSingleEditOperation(){return{range:this.range,text:this.text}}}class I{static inverse(e,t,n){const r=[];let i=1,s=1;for(const a of e){const e=new I(new x.M(i,a.original.startLineNumber),new x.M(s,a.modified.startLineNumber));e.modified.isEmpty||r.push(e),i=a.original.endLineNumberExclusive,s=a.modified.endLineNumberExclusive}const o=new I(new x.M(i,t+1),new x.M(s,n+1));return o.modified.isEmpty||r.push(o),r}static clip(e,t,n){const r=[];for(const i of e){const e=i.original.intersect(t),s=i.modified.intersect(n);e&&!e.isEmpty&&s&&!s.isEmpty&&r.push(new I(e,s))}return r}constructor(e,t){this.original=e,this.modified=t}toString(){return`{${this.original.toString()}->${this.modified.toString()}}`}flip(){return new I(this.modified,this.original)}join(e){return new I(this.original.join(e.original),this.modified.join(e.modified))}toRangeMapping(){const e=this.original.toInclusiveRange(),t=this.modified.toInclusiveRange();if(e&&t)return new D(e,t);if(1===this.original.startLineNumber||1===this.modified.startLineNumber){if(1!==this.modified.startLineNumber||1!==this.original.startLineNumber)throw new S.D7("not a valid diff");return new D(new u.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new u.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1))}return new D(new u.Q(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),new u.Q(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER))}toRangeMapping2(e,t){if(M(this.original.endLineNumberExclusive,e)&&M(this.modified.endLineNumberExclusive,t))return new D(new u.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new u.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1));if(!this.original.isEmpty&&!this.modified.isEmpty)return new D(u.Q.fromPositions(new E.y(this.original.startLineNumber,1),O(new E.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),u.Q.fromPositions(new E.y(this.modified.startLineNumber,1),O(new E.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));if(this.original.startLineNumber>1&&this.modified.startLineNumber>1)return new D(u.Q.fromPositions(O(new E.y(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER),e),O(new E.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),u.Q.fromPositions(O(new E.y(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER),t),O(new E.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));throw new S.D7}}function O(e,t){if(e.lineNumber<1)return new E.y(1,1);if(e.lineNumber>t.length)return new E.y(t.length,t[t.length-1].length+1);const n=t[e.lineNumber-1];return e.column>n.length+1?new E.y(e.lineNumber,n.length+1):e}function M(e,t){return e>=1&&e<=t.length}class R extends I{static fromRangeMappings(e){const t=x.M.join(e.map((e=>x.M.fromRangeInclusive(e.originalRange)))),n=x.M.join(e.map((e=>x.M.fromRangeInclusive(e.modifiedRange))));return new R(t,n,e)}constructor(e,t,n){super(e,t),this.innerChanges=n}flip(){return new R(this.modified,this.original,this.innerChanges?.map((e=>e.flip())))}withInnerChangesFromLineRanges(){return new R(this.original,this.modified,[this.toRangeMapping()])}}class D{static assertSorted(e){for(let t=1;t${this.modifiedRange.toString()}}`}flip(){return new D(this.modifiedRange,this.originalRange)}toTextEdit(e){const t=e.getValueOfRange(this.modifiedRange);return new A(this.originalRange,t)}}var B=n(1508);class F{computeDiff(e,t,n){const r=new W(e,t,{maxComputationTime:n.maxComputationTimeMs,shouldIgnoreTrimWhitespace:n.ignoreTrimWhitespace,shouldComputeCharChanges:!0,shouldMakePrettyDiff:!0,shouldPostProcessCharChanges:!0}).computeDiff(),i=[];let s=null;for(const o of r.changes){let e,t;e=0===o.originalEndLineNumber?new x.M(o.originalStartLineNumber+1,o.originalStartLineNumber+1):new x.M(o.originalStartLineNumber,o.originalEndLineNumber+1),t=0===o.modifiedEndLineNumber?new x.M(o.modifiedStartLineNumber+1,o.modifiedStartLineNumber+1):new x.M(o.modifiedStartLineNumber,o.modifiedEndLineNumber+1);let n=new R(e,t,o.charChanges?.map((e=>new D(new u.Q(e.originalStartLineNumber,e.originalStartColumn,e.originalEndLineNumber,e.originalEndColumn),new u.Q(e.modifiedStartLineNumber,e.modifiedStartColumn,e.modifiedEndLineNumber,e.modifiedEndColumn)))));s&&(s.modified.endLineNumberExclusive!==n.modified.startLineNumber&&s.original.endLineNumberExclusive!==n.original.startLineNumber||(n=new R(s.original.join(n.original),s.modified.join(n.modified),s.innerChanges&&n.innerChanges?s.innerChanges.concat(n.innerChanges):void 0),i.pop())),i.push(n),s=n}return(0,N.Ft)((()=>(0,N.Xo)(i,((e,t)=>t.original.startLineNumber-e.original.endLineNumberExclusive===t.modified.startLineNumber-e.modified.endLineNumberExclusive&&e.original.endLineNumberExclusive(10===e?"\\n":String.fromCharCode(e))+`-(${this._lineNumbers[t]},${this._columns[t]})`)).join(", ")+"]"}_assertIndex(e,t){if(e<0||e>=t.length)throw new Error("Illegal index")}getElements(){return this._charCodes}getStartLineNumber(e){return e>0&&e===this._lineNumbers.length?this.getEndLineNumber(e-1):(this._assertIndex(e,this._lineNumbers),this._lineNumbers[e])}getEndLineNumber(e){return-1===e?this.getStartLineNumber(e+1):(this._assertIndex(e,this._lineNumbers),10===this._charCodes[e]?this._lineNumbers[e]+1:this._lineNumbers[e])}getStartColumn(e){return e>0&&e===this._columns.length?this.getEndColumn(e-1):(this._assertIndex(e,this._columns),this._columns[e])}getEndColumn(e){return-1===e?this.getStartColumn(e+1):(this._assertIndex(e,this._columns),10===this._charCodes[e]?1:this._columns[e]+1)}}class j{constructor(e,t,n,r,i,s,o,a){this.originalStartLineNumber=e,this.originalStartColumn=t,this.originalEndLineNumber=n,this.originalEndColumn=r,this.modifiedStartLineNumber=i,this.modifiedStartColumn=s,this.modifiedEndLineNumber=o,this.modifiedEndColumn=a}static createFromDiffChange(e,t,n){const r=t.getStartLineNumber(e.originalStart),i=t.getStartColumn(e.originalStart),s=t.getEndLineNumber(e.originalStart+e.originalLength-1),o=t.getEndColumn(e.originalStart+e.originalLength-1),a=n.getStartLineNumber(e.modifiedStart),l=n.getStartColumn(e.modifiedStart),c=n.getEndLineNumber(e.modifiedStart+e.modifiedLength-1),h=n.getEndColumn(e.modifiedStart+e.modifiedLength-1);return new j(r,i,s,o,a,l,c,h)}}class q{constructor(e,t,n,r,i){this.originalStartLineNumber=e,this.originalEndLineNumber=t,this.modifiedStartLineNumber=n,this.modifiedEndLineNumber=r,this.charChanges=i}static createFromDiffResult(e,t,n,r,i,s,o){let a,l,c,h,u;if(0===t.originalLength?(a=n.getStartLineNumber(t.originalStart)-1,l=0):(a=n.getStartLineNumber(t.originalStart),l=n.getEndLineNumber(t.originalStart+t.originalLength-1)),0===t.modifiedLength?(c=r.getStartLineNumber(t.modifiedStart)-1,h=0):(c=r.getStartLineNumber(t.modifiedStart),h=r.getEndLineNumber(t.modifiedStart+t.modifiedLength-1)),s&&t.originalLength>0&&t.originalLength<20&&t.modifiedLength>0&&t.modifiedLength<20&&i()){const s=n.createCharSequence(e,t.originalStart,t.originalStart+t.originalLength-1),a=r.createCharSequence(e,t.modifiedStart,t.modifiedStart+t.modifiedLength-1);if(s.getElements().length>0&&a.getElements().length>0){let e=P(s,a,i,!0).changes;o&&(e=function(e){if(e.length<=1)return e;const t=[e[0]];let n=t[0];for(let r=1,i=e.length;r1&&o>1;){if(e.charCodeAt(n-2)!==t.charCodeAt(o-2))break;n--,o--}(n>1||o>1)&&this._pushTrimWhitespaceCharChange(r,i+1,1,n,s+1,1,o)}{let n=$(e,1),o=$(t,1);const a=e.length+1,l=t.length+1;for(;n!0;const t=Date.now();return()=>Date.now()-t{n.push(Q.fromOffsetPairs(e?e.getEndExclusives():J.zero,r?r.getStarts():new J(t,(e?e.seq2Range.endExclusive-e.seq1Range.endExclusive:0)+t)))})),n}static fromOffsetPairs(e,t){return new Q(new T.L(e.offset1,t.offset1),new T.L(e.offset2,t.offset2))}static assertSorted(e){let t;for(const n of e){if(t&&!(t.seq1Range.endExclusive<=n.seq1Range.start&&t.seq2Range.endExclusive<=n.seq2Range.start))throw new S.D7("Sequence diffs must be sorted");t=n}}constructor(e,t){this.seq1Range=e,this.seq2Range=t}swap(){return new Q(this.seq2Range,this.seq1Range)}toString(){return`${this.seq1Range} <-> ${this.seq2Range}`}join(e){return new Q(this.seq1Range.join(e.seq1Range),this.seq2Range.join(e.seq2Range))}delta(e){return 0===e?this:new Q(this.seq1Range.delta(e),this.seq2Range.delta(e))}deltaStart(e){return 0===e?this:new Q(this.seq1Range.deltaStart(e),this.seq2Range.deltaStart(e))}deltaEnd(e){return 0===e?this:new Q(this.seq1Range.deltaEnd(e),this.seq2Range.deltaEnd(e))}intersect(e){const t=this.seq1Range.intersect(e.seq1Range),n=this.seq2Range.intersect(e.seq2Range);if(t&&n)return new Q(t,n)}getStarts(){return new J(this.seq1Range.start,this.seq2Range.start)}getEndExclusives(){return new J(this.seq1Range.endExclusive,this.seq2Range.endExclusive)}}class J{static{this.zero=new J(0,0)}static{this.max=new J(Number.MAX_SAFE_INTEGER,Number.MAX_SAFE_INTEGER)}constructor(e,t){this.offset1=e,this.offset2=t}toString(){return`${this.offset1} <-> ${this.offset2}`}delta(e){return 0===e?this:new J(this.offset1+e,this.offset2+e)}equals(e){return this.offset1===e.offset1&&this.offset2===e.offset2}}class X{static{this.instance=new X}isValid(){return!0}}class Y{constructor(e){if(this.timeout=e,this.startTime=Date.now(),this.valid=!0,e<=0)throw new S.D7("timeout must be positive")}isValid(){return!(Date.now()-this.startTime0&&a>0&&3===s.get(g-1,a-1)&&(h+=o.get(g-1,a-1)),h+=r?r(g,a):1):h=-1;const u=Math.max(l,c,h);if(u===h){const e=g>0&&a>0?o.get(g-1,a-1):0;o.set(g,a,e+1),s.set(g,a,3)}else u===l?(o.set(g,a,0),s.set(g,a,1)):u===c&&(o.set(g,a,0),s.set(g,a,2));i.set(g,a,u)}const a=[];let l=e.length,c=t.length;function h(e,t){e+1===l&&t+1===c||a.push(new Q(new T.L(e+1,l),new T.L(t+1,c))),l=e,c=t}let u=e.length-1,d=t.length-1;for(;u>=0&&d>=0;)3===s.get(u,d)?(h(u,d),u--,d--):1===s.get(u,d)?u--:d--;return h(-1,-1),a.reverse(),new G(a,!1)}}class re{compute(e,t,n=X.instance){if(0===e.length||0===t.length)return G.trivial(e,t);const r=e,i=t;function s(e,t){for(;er.length||d>i.length)continue;const g=s(u,d);a.set(c,g);const f=u===o?l.get(c+1):l.get(c-1);if(l.set(c,g!==u?new ie(f,u,d,g-u):f),a.get(c)===r.length&&a.get(c)-c===i.length)break e}}let h=l.get(c);const u=[];let d=r.length,g=i.length;for(;;){const e=h?h.x+h.length:0,t=h?h.y+h.length:0;if(e===d&&t===g||u.push(new Q(new T.L(e,d),new T.L(t,g))),!h)break;d=h.x,g=h.y,h=h.prev}return u.reverse(),new G(u,!1)}}class ie{constructor(e,t,n,r){this.prev=e,this.x=t,this.y=n,this.length=r}}class se{constructor(){this.positiveArr=new Int32Array(10),this.negativeArr=new Int32Array(10)}get(e){return e<0?(e=-e-1,this.negativeArr[e]):this.positiveArr[e]}set(e,t){if(e<0){if((e=-e-1)>=this.negativeArr.length){const e=this.negativeArr;this.negativeArr=new Int32Array(2*e.length),this.negativeArr.set(e)}this.negativeArr[e]=t}else{if(e>=this.positiveArr.length){const e=this.positiveArr;this.positiveArr=new Int32Array(2*e.length),this.positiveArr.set(e)}this.positiveArr[e]=t}}}class oe{constructor(){this.positiveArr=[],this.negativeArr=[]}get(e){return e<0?(e=-e-1,this.negativeArr[e]):this.positiveArr[e]}set(e,t){e<0?(e=-e-1,this.negativeArr[e]=t):this.positiveArr[e]=t}}var ae=n(6041),le=n(4320);class ce{constructor(e,t,n){this.lines=e,this.range=t,this.considerWhitespaceChanges=n,this.elements=[],this.firstElementOffsetByLineIdx=[],this.lineStartOffsets=[],this.trimmedWsLengthsByLineIdx=[],this.firstElementOffsetByLineIdx.push(0);for(let r=this.range.startLineNumber;r<=this.range.endLineNumber;r++){let t=e[r-1],i=0;r===this.range.startLineNumber&&this.range.startColumn>1&&(i=this.range.startColumn-1,t=t.substring(i)),this.lineStartOffsets.push(i);let s=0;if(!n){const e=t.trimStart();s=t.length-e.length,t=e.trimEnd()}this.trimmedWsLengthsByLineIdx.push(s);const o=r===this.range.endLineNumber?Math.min(this.range.endColumn-1-i-s,t.length):t.length;for(let e=0;eString.fromCharCode(e))).join("")}getElement(e){return this.elements[e]}get length(){return this.elements.length}getBoundaryScore(e){const t=ge(e>0?this.elements[e-1]:-1),n=ge(et<=e)),r=e-this.firstElementOffsetByLineIdx[n];return new E.y(this.range.startLineNumber+n,1+this.lineStartOffsets[n]+r+(0===r&&"left"===t?0:this.trimmedWsLengthsByLineIdx[n]))}translateRange(e){const t=this.translateOffset(e.start,"right"),n=this.translateOffset(e.endExclusive,"left");return n.isBefore(t)?u.Q.fromPositions(n,n):u.Q.fromPositions(t,n)}findWordContaining(e){if(e<0||e>=this.elements.length)return;if(!he(this.elements[e]))return;let t=e;for(;t>0&&he(this.elements[t-1]);)t--;let n=e;for(;nt<=e.start))??0,n=(0,ae.XP)(this.firstElementOffsetByLineIdx,(t=>e.endExclusive<=t))??this.elements.length;return new T.L(t,n)}}function he(e){return e>=97&&e<=122||e>=65&&e<=90||e>=48&&e<=57}const ue={0:0,1:0,2:0,3:10,4:2,5:30,6:3,7:10,8:10};function de(e){return ue[e]}function ge(e){return 10===e?8:13===e?7:ee(e)?6:e>=97&&e<=122?0:e>=65&&e<=90?1:e>=48&&e<=57?2:-1===e?3:44===e||59===e?5:4}function fe(e,t,n,r,i,s){let{moves:o,excludedChanges:a}=function(e,t,n,r){const i=[],s=e.filter((e=>e.modified.isEmpty&&e.original.length>=3)).map((e=>new te(e.original,t,e))),o=new Set(e.filter((e=>e.original.isEmpty&&e.modified.length>=3)).map((e=>new te(e.modified,n,e)))),a=new Set;for(const l of s){let e,t=-1;for(const n of o){const r=l.computeSimilarity(n);r>t&&(t=r,e=n)}if(t>.9&&e&&(o.delete(e),i.push(new I(l.range,e.range)),a.add(l.source),a.add(e.source)),!r.isValid())return{moves:i,excludedChanges:a}}return{moves:i,excludedChanges:a}}(e,t,n,s);if(!s.isValid())return[];const l=function(e,t,n,r,i,s){const o=[],a=new le.db;for(const d of e)for(let e=d.original.startLineNumber;ee.modified.startLineNumber),K.U9));for(const d of e){let e=[];for(let t=d.modified.startLineNumber;t{for(const r of e)if(r.originalLineRange.endLineNumberExclusive+1===t.endLineNumberExclusive&&r.modifiedLineRange.endLineNumberExclusive+1===i.endLineNumberExclusive)return r.originalLineRange=new x.M(r.originalLineRange.startLineNumber,t.endLineNumberExclusive),r.modifiedLineRange=new x.M(r.modifiedLineRange.startLineNumber,i.endLineNumberExclusive),void s.push(r);const n={modifiedLineRange:i,originalLineRange:t};l.push(n),s.push(n)})),e=s}if(!s.isValid())return[]}l.sort((0,K.Hw)((0,K.VE)((e=>e.modifiedLineRange.length),K.U9)));const c=new x.S,h=new x.S;for(const d of l){const e=d.modifiedLineRange.startLineNumber-d.originalLineRange.startLineNumber,t=c.subtractFrom(d.modifiedLineRange),n=h.subtractFrom(d.originalLineRange).getWithDelta(e),r=t.getIntersection(n);for(const i of r.ranges){if(i.length<3)continue;const t=i,n=i.delta(-e);o.push(new I(n,t)),c.addRange(t),h.addRange(n)}}o.sort((0,K.VE)((e=>e.original.startLineNumber),K.U9));const u=new ae.vJ(e);for(let d=0;de.original.startLineNumber<=t.original.startLineNumber)),a=(0,ae.lx)(e,(e=>e.modified.startLineNumber<=t.modified.startLineNumber)),l=Math.max(t.original.startLineNumber-n.original.startLineNumber,t.modified.startLineNumber-a.modified.startLineNumber),g=u.findLastMonotonous((e=>e.original.startLineNumbere.modified.startLineNumberr.length||n>i.length)break;if(c.contains(n)||h.contains(e))break;if(!me(r[e-1],i[n-1],s))break}for(p>0&&(h.addRange(new x.M(t.original.startLineNumber-p,t.original.startLineNumber)),c.addRange(new x.M(t.modified.startLineNumber-p,t.modified.startLineNumber))),b=0;br.length||n>i.length)break;if(c.contains(n)||h.contains(e))break;if(!me(r[e-1],i[n-1],s))break}b>0&&(h.addRange(new x.M(t.original.endLineNumberExclusive,t.original.endLineNumberExclusive+b)),c.addRange(new x.M(t.modified.endLineNumberExclusive,t.modified.endLineNumberExclusive+b))),(p>0||b>0)&&(o[d]=new I(new x.M(t.original.startLineNumber-p,t.original.endLineNumberExclusive+b),new x.M(t.modified.startLineNumber-p,t.modified.endLineNumberExclusive+b)))}return o}(e.filter((e=>!a.has(e))),r,i,t,n,s);return(0,K.E4)(o,l),o=function(e){if(0===e.length)return e;e.sort((0,K.VE)((e=>e.original.startLineNumber),K.U9));const t=[e[0]];for(let n=1;n=0&&o>=0&&s+o<=2?t[t.length-1]=r.join(i):t.push(i)}return t}(o),o=o.filter((e=>{const n=e.original.toOffsetRange().slice(t).map((e=>e.trim()));return n.join("\n").length>=15&&function(e,t){let n=0;for(const r of e)t(r)&&n++;return n}(n,(e=>e.length>=2))>=2})),o=function(e,t){const n=new ae.vJ(e);return t=t.filter((t=>(n.findLastMonotonous((e=>e.original.startLineNumbere.modified.startLineNumber300&&t.length>300)return!1;const r=(new re).compute(new ce([e],new u.Q(1,1,1,e.length),!1),new ce([t],new u.Q(1,1,1,t.length),!1),n);let i=0;const s=Q.invert(r.diffs,e.length);for(const a of s)a.seq1Range.forEach((t=>{ee(e.charCodeAt(t))||i++}));const o=function(t){let n=0;for(let r=0;rt.length?e:t);return i/o>.6&&o>10}function pe(e,t,n){let r=n;return r=be(e,t,r),r=be(e,t,r),r=function(e,t,n){if(!e.getBoundaryScore||!t.getBoundaryScore)return n;for(let r=0;r0?n[r-1]:void 0,s=n[r],o=r+10&&(o=o.delta(a))}i.push(o)}return r.length>0&&i.push(r[r.length-1]),i}function _e(e,t,n,r,i){let s=1;for(;e.seq1Range.start-s>=r.start&&e.seq2Range.start-s>=i.start&&n.isStronglyEqual(e.seq2Range.start-s,e.seq2Range.endExclusive-s)&&s<100;)s++;s--;let o=0;for(;e.seq1Range.start+ol&&(l=o,a=c)}return e.delta(a)}class ke{constructor(e,t){this.trimmedHash=e,this.lines=t}getElement(e){return this.trimmedHash[e]}get length(){return this.trimmedHash.length}getBoundaryScore(e){return 1e3-((0===e?0:ve(this.lines[e-1]))+(e===this.lines.length?0:ve(this.lines[e])))}getText(e){return this.lines.slice(e.start,e.endExclusive).join("\n")}isStronglyEqual(e,t){return this.lines[e]===this.lines[t]}}function ve(e){let t=0;for(;te===t)))return new L([],[],!1);if(1===e.length&&0===e[0].length||1===t.length&&0===t[0].length)return new L([new R(new x.M(1,e.length+1),new x.M(1,t.length+1),[new D(new u.Q(1,1,e.length,e[e.length-1].length+1),new u.Q(1,1,t.length,t[t.length-1].length+1))])],[],!1);const r=0===n.maxComputationTimeMs?X.instance:new Y(n.maxComputationTimeMs),i=!n.ignoreTrimWhitespace,s=new Map;function o(e){let t=s.get(e);return void 0===t&&(t=s.size,s.set(e,t)),t}const a=e.map((e=>o(e.trim()))),l=t.map((e=>o(e.trim()))),c=new ke(a,e),h=new ke(l,t),d=(()=>c.length+h.length<1700?this.dynamicProgrammingDiffing.compute(c,h,r,((n,r)=>e[n]===t[r]?0===t[r].length?.1:1+Math.log(1+t[r].length):.99)):this.myersDiffingAlgorithm.compute(c,h,r))();let g=d.diffs,f=d.hitTimeout;g=pe(c,h,g),g=function(e,t,n){let r=n;if(0===r.length)return r;let i,s=0;do{i=!1;const o=[r[0]];for(let a=1;a5||n.seq1Range.length+n.seq2Range.length>5)}h(c,l)?(i=!0,o[o.length-1]=o[o.length-1].join(l)):o.push(l)}r=o}while(s++<10&&i);return r}(c,0,g);const m=[],p=n=>{if(i)for(let s=0;su.seq1Range.start-b===u.seq2Range.start-_));p(u.seq1Range.start-b),b=u.seq1Range.endExclusive,_=u.seq2Range.endExclusive;const n=this.refineDiff(e,t,u,r,i);n.hitTimeout&&(f=!0);for(const e of n.mappings)m.push(e)}p(e.length-b);const k=ye(m,e,t);let v=[];return n.computeMoves&&(v=this.computeMoves(k,e,t,a,l,r,i)),(0,N.Ft)((()=>{function n(e,t){if(e.lineNumber<1||e.lineNumber>t.length)return!1;const n=t[e.lineNumber-1];return!(e.column<1||e.column>n.length+1)}function r(e,t){return!(e.startLineNumber<1||e.startLineNumber>t.length+1)&&!(e.endLineNumberExclusive<1||e.endLineNumberExclusive>t.length+1)}for(const i of k){if(!i.innerChanges)return!1;for(const r of i.innerChanges){if(!(n(r.modifiedRange.getStartPosition(),t)&&n(r.modifiedRange.getEndPosition(),t)&&n(r.originalRange.getStartPosition(),e)&&n(r.originalRange.getEndPosition(),e)))return!1}if(!r(i.modified,t)||!r(i.original,e))return!1}return!0})),new L(k,v,f)}computeMoves(e,t,n,r,i,s,o){return fe(e,t,n,r,i,s).map((e=>{const r=ye(this.refineDiff(t,n,new Q(e.original.toOffsetRange(),e.modified.toOffsetRange()),s,o).mappings,t,n,!0);return new w(e,r)}))}refineDiff(e,t,n,r,i){var s;const o=(s=n,new I(new x.M(s.seq1Range.start+1,s.seq1Range.endExclusive+1),new x.M(s.seq2Range.start+1,s.seq2Range.endExclusive+1))).toRangeMapping2(e,t),a=new ce(e,o.originalRange,i),l=new ce(t,o.modifiedRange,i),c=a.length+l.length<500?this.dynamicProgrammingDiffing.compute(a,l,r):this.myersDiffingAlgorithm.compute(a,l,r),h=!1;let u=c.diffs;u=pe(a,l,u),u=function(e,t,n){const r=Q.invert(n,e.length),i=[];let s=new J(0,0);function o(n,o){if(n.offset10;){const n=r[0];if(!n.seq1Range.intersects(c.seq1Range)&&!n.seq2Range.intersects(c.seq2Range))break;const i=e.findWordContaining(n.seq1Range.start),s=t.findWordContaining(n.seq2Range.start),o=new Q(i,s),a=o.intersect(n);if(u+=a.seq1Range.length,d+=a.seq2Range.length,c=c.join(o),!(c.seq1Range.endExclusive>=n.seq1Range.endExclusive))break;r.shift()}u+d<2*(c.seq1Range.length+c.seq2Range.length)/3&&i.push(c),s=c.getEndExclusives()}for(;r.length>0;){const e=r.shift();e.seq1Range.isEmpty||(o(e.getStarts(),e),o(e.getEndExclusives().delta(-1),e))}return function(e,t){const n=[];for(;e.length>0||t.length>0;){const r=e[0],i=t[0];let s;s=r&&(!i||r.seq1Range.start0&&n[n.length-1].seq1Range.endExclusive>=s.seq1Range.start?n[n.length-1]=n[n.length-1].join(s):n.push(s)}return n}(n,i)}(a,l,u),u=function(e,t,n){const r=[];for(const i of n){const e=r[r.length-1];e&&(i.seq1Range.start-e.seq1Range.endExclusive<=2||i.seq2Range.start-e.seq2Range.endExclusive<=2)?r[r.length-1]=new Q(e.seq1Range.join(i.seq1Range),e.seq2Range.join(i.seq2Range)):r.push(i)}return r}(0,0,u),u=function(e,t,n){let r=n;if(0===r.length)return r;let i,s=0;do{i=!1;const a=[r[0]];for(let l=1;l5||i.length>500)return!1;const s=e.getText(i).trim();if(s.length>20||s.split(/\r\n|\r|\n/).length>1)return!1;const o=e.countLinesIn(n.seq1Range),a=n.seq1Range.length,l=t.countLinesIn(n.seq2Range),u=n.seq2Range.length,d=e.countLinesIn(r.seq1Range),g=r.seq1Range.length,f=t.countLinesIn(r.seq2Range),m=r.seq2Range.length;function p(e){return Math.min(e,130)}return Math.pow(Math.pow(p(40*o+a),1.5)+Math.pow(p(40*l+u),1.5),1.5)+Math.pow(Math.pow(p(40*d+g),1.5)+Math.pow(p(40*f+m),1.5),1.5)>74184.96480721243}u(h,c)?(i=!0,a[a.length-1]=a[a.length-1].join(c)):a.push(c)}r=a}while(s++<10&&i);const o=[];return(0,K.kj)(r,((t,n,r)=>{let i=n;function s(e){return e.length>0&&e.trim().length<=3&&n.seq1Range.length+n.seq2Range.length>100}const a=e.extendToFullLines(n.seq1Range),l=e.getText(new T.L(a.start,n.seq1Range.start));s(l)&&(i=i.deltaStart(-l.length));const c=e.getText(new T.L(n.seq1Range.endExclusive,a.endExclusive));s(c)&&(i=i.deltaEnd(c.length));const h=Q.fromOffsetPairs(t?t.getEndExclusives():J.zero,r?r.getStarts():J.max),u=i.intersect(h);o.length>0&&u.getStarts().equals(o[o.length-1].getEndExclusives())?o[o.length-1]=o[o.length-1].join(u):o.push(u)})),o}(a,l,u);const d=u.map((e=>new D(a.translateRange(e.seq1Range),l.translateRange(e.seq2Range))));return{mappings:d,hitTimeout:c.hitTimeout}}}function ye(e,t,n,r=!1){const i=[];for(const s of(0,K.n)(e.map((e=>function(e,t,n){let r=0,i=0;1===e.modifiedRange.endColumn&&1===e.originalRange.endColumn&&e.originalRange.startLineNumber+r<=e.originalRange.endLineNumber&&e.modifiedRange.startLineNumber+r<=e.modifiedRange.endLineNumber&&(i=-1);e.modifiedRange.startColumn-1>=n[e.modifiedRange.startLineNumber-1].length&&e.originalRange.startColumn-1>=t[e.originalRange.startLineNumber-1].length&&e.originalRange.startLineNumber<=e.originalRange.endLineNumber+i&&e.modifiedRange.startLineNumber<=e.modifiedRange.endLineNumber+i&&(r=1);const s=new x.M(e.originalRange.startLineNumber+r,e.originalRange.endLineNumber+1+i),o=new x.M(e.modifiedRange.startLineNumber+r,e.modifiedRange.endLineNumber+1+i);return new R(s,o,[e])}(e,t,n))),((e,t)=>e.original.overlapOrTouch(t.original)||e.modified.overlapOrTouch(t.modified)))){const e=s[0],t=s[s.length-1];i.push(new R(e.original.join(t.original),e.modified.join(t.modified),s.map((e=>e.innerChanges[0]))))}return(0,N.Ft)((()=>{if(!r&&i.length>0){if(i[0].modified.startLineNumber!==i[0].original.startLineNumber)return!1;if(n.length-i[i.length-1].modified.endLineNumberExclusive!==t.length-i[i.length-1].original.endLineNumberExclusive)return!1}return(0,N.Xo)(i,((e,t)=>t.original.startLineNumber-e.original.endLineNumberExclusive===t.modified.startLineNumber-e.modified.endLineNumberExclusive&&e.original.endLineNumberExclusivenew F,we=()=>new Ce;var Se=n(146),xe=n(6456),Ee=n(7661);function Ne(e){const t=[];for(const n of e){const e=Number(n);(e||0===e&&""!==n.replace(/\s/g,""))&&t.push(e)}return t}function Te(e,t,n,r){return{red:e/255,blue:n/255,green:t/255,alpha:r}}function Ae(e,t){const n=t.index,r=t[0].length;if(!n)return;const i=e.positionAt(n);return{startLineNumber:i.lineNumber,startColumn:i.column,endLineNumber:i.lineNumber,endColumn:i.column+r}}function Ie(e,t){if(!e)return;const n=Ee.Q1.Format.CSS.parseHex(t);return n?{range:e,color:Te(n.rgba.r,n.rgba.g,n.rgba.b,n.rgba.a)}:void 0}function Oe(e,t,n){if(!e||1!==t.length)return;const r=Ne(t[0].values());return{range:e,color:Te(r[0],r[1],r[2],n?r[3]:1)}}function Me(e,t,n){if(!e||1!==t.length)return;const r=Ne(t[0].values()),i=new Ee.Q1(new Ee.hB(r[0],r[1]/100,r[2]/100,n?r[3]:1));return{range:e,color:Te(i.rgba.r,i.rgba.g,i.rgba.b,i.rgba.a)}}function Re(e,t){return"string"===typeof e?[...e.matchAll(t)]:e.findMatches(t)}function De(e){return e&&"function"===typeof e.getValue&&"function"===typeof e.positionAt?function(e){const t=[],n=Re(e,/\b(rgb|rgba|hsl|hsla)(\([0-9\s,.\%]*\))|(#)([A-Fa-f0-9]{3})\b|(#)([A-Fa-f0-9]{4})\b|(#)([A-Fa-f0-9]{6})\b|(#)([A-Fa-f0-9]{8})\b/gm);if(n.length>0)for(const r of n){const n=r.filter((e=>void 0!==e)),i=n[1],s=n[2];if(!s)continue;let o;if("rgb"===i){const t=/^\(\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*\)$/gm;o=Oe(Ae(e,r),Re(s,t),!1)}else if("rgba"===i){const t=/^\(\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(0[.][0-9]+|[.][0-9]+|[01][.]|[01])\s*\)$/gm;o=Oe(Ae(e,r),Re(s,t),!0)}else if("hsl"===i){const t=/^\(\s*(36[0]|3[0-5][0-9]|[12][0-9][0-9]|[1-9]?[0-9])\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*\)$/gm;o=Me(Ae(e,r),Re(s,t),!1)}else if("hsla"===i){const t=/^\(\s*(36[0]|3[0-5][0-9]|[12][0-9][0-9]|[1-9]?[0-9])\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(0[.][0-9]+|[.][0-9]+|[01][.]|[01])\s*\)$/gm;o=Me(Ae(e,r),Re(s,t),!0)}else"#"===i&&(o=Ie(Ae(e,r),i+s));o&&t.push(o)}return t}(e):[]}var Be=n(6691),Fe=n(796);class Pe{constructor(){this._workerTextModelSyncServer=new Fe.WorkerTextModelSyncServer}dispose(){}_getModel(e){return this._workerTextModelSyncServer.getModel(e)}_getModels(){return this._workerTextModelSyncServer.getModels()}$acceptNewModel(e){this._workerTextModelSyncServer.$acceptNewModel(e)}$acceptModelChanged(e,t){this._workerTextModelSyncServer.$acceptModelChanged(e,t)}$acceptRemovedModel(e){this._workerTextModelSyncServer.$acceptRemovedModel(e)}async $computeUnicodeHighlights(e,t,n){const r=this._getModel(e);return r?y.UnicodeTextModelHighlighter.computeUnicodeHighlights(r,t,n):{ranges:[],hasMore:!1,ambiguousCharacterCount:0,invisibleCharacterCount:0,nonBasicAsciiCharacterCount:0}}async $findSectionHeaders(e,t){const n=this._getModel(e);return n?(0,Be.findSectionHeaders)(n,t):[]}async $computeDiff(e,t,n,r){const i=this._getModel(e),s=this._getModel(t);if(!i||!s)return null;return Ve.computeDiff(i,s,n,r)}static computeDiff(e,t,n,r){const i="advanced"===r?we():Le(),s=e.getLinesContent(),o=t.getLinesContent(),a=i.computeDiff(s,o,n);function l(e){return e.map((e=>[e.original.startLineNumber,e.original.endLineNumberExclusive,e.modified.startLineNumber,e.modified.endLineNumberExclusive,e.innerChanges?.map((e=>[e.originalRange.startLineNumber,e.originalRange.startColumn,e.originalRange.endLineNumber,e.originalRange.endColumn,e.modifiedRange.startLineNumber,e.modifiedRange.startColumn,e.modifiedRange.endLineNumber,e.modifiedRange.endColumn]))]))}return{identical:!(a.changes.length>0)&&this._modelsAreIdentical(e,t),quitEarly:a.hitTimeout,changes:l(a.changes),moves:a.moves.map((e=>[e.lineRangeMapping.original.startLineNumber,e.lineRangeMapping.original.endLineNumberExclusive,e.lineRangeMapping.modified.startLineNumber,e.lineRangeMapping.modified.endLineNumberExclusive,l(e.changes)]))}}static _modelsAreIdentical(e,t){const n=e.getLineCount();if(n!==t.getLineCount())return!1;for(let r=1;r<=n;r++){if(e.getLineContent(r)!==t.getLineContent(r))return!1}return!0}static{this._diffLimit=1e5}async $computeMoreMinimalEdits(e,t,n){const r=this._getModel(e);if(!r)return t;const i=[];let s;t=t.slice(0).sort(((e,t)=>{if(e.range&&t.range)return u.Q.compareRangesUsingStarts(e.range,t.range);return(e.range?0:1)-(t.range?0:1)}));let a=0;for(let o=1;oVe._diffLimit){i.push({range:l,text:c});continue}const t=o(e,c,n),a=r.offsetAt(u.Q.lift(l).getStartPosition());for(const n of t){const e=r.positionAt(a+n.originalStart),t=r.positionAt(a+n.originalStart+n.originalLength),s={text:c.substr(n.modifiedStart,n.modifiedLength),range:{startLineNumber:e.lineNumber,startColumn:e.column,endLineNumber:t.lineNumber,endColumn:t.column}};r.getValueInRange(s.range)!==s.text&&i.push(s)}}return"number"===typeof s&&i.push({eol:s,text:"",range:{startLineNumber:0,startColumn:0,endLineNumber:0,endColumn:0}}),i}async $computeLinks(e){const t=this._getModel(e);return t?function(e){return e&&"function"===typeof e.getLineCount&&"function"===typeof e.getLineContent?b.computeLinks(e):[]}(t):null}async $computeDefaultDocumentColors(e){const t=this._getModel(e);return t?De(t):null}static{this._suggestionsLimit=1e4}async $textualSuggest(e,t,n,r){const i=new C.W,s=new RegExp(n,r),o=new Set;e:for(const a of e){const e=this._getModel(a);if(e)for(const n of e.words(s))if(n!==t&&isNaN(Number(n))&&(o.add(n),o.size>Ve._suggestionsLimit))break e}return{words:Array.from(o),duration:i.elapsed()}}async $computeWordRanges(e,t,n,r){const i=this._getModel(e);if(!i)return Object.create(null);const s=new RegExp(n,r),o=Object.create(null);for(let a=t.startLineNumber;athis._host.$fhr(e,t))),getMirrorModels:()=>this._getModels()};return this._foreignModuleFactory?(this._foreignModule=this._foreignModuleFactory(i,t),Promise.resolve((0,Se.V0)(this._foreignModule))):new Promise(((r,s)=>{const o=e=>{this._foreignModule=e.create(i,t),r((0,Se.V0)(this._foreignModule))};{const t=xe.zl.asBrowserUri(`${e}.js`).toString(!0);n(9204)(`${t}`).then(o).catch(s)}}))}$fmr(e,t){if(!this._foreignModule||"function"!==typeof this._foreignModule[e])return Promise.reject(new Error("Missing requestHandler or method: "+e));try{return Promise.resolve(this._foreignModule[e].apply(this._foreignModule,t))}catch(n){return Promise.reject(n)}}}function ze(e){return new Ve(v.EditorWorkerHost.getChannel(e),null)}"function"===typeof importScripts&&(globalThis.monaco=(0,k.createMonacoBaseAPI)())},5326:(e,t,n)=>{"use strict";n.d(t,{L:()=>s});var r=n(3069),i=n(6677);class s extends i.Q{constructor(e,t,n,r){super(e,t,n,r),this.selectionStartLineNumber=e,this.selectionStartColumn=t,this.positionLineNumber=n,this.positionColumn=r}toString(){return"["+this.selectionStartLineNumber+","+this.selectionStartColumn+" -> "+this.positionLineNumber+","+this.positionColumn+"]"}equalsSelection(e){return s.selectionsEqual(this,e)}static selectionsEqual(e,t){return e.selectionStartLineNumber===t.selectionStartLineNumber&&e.selectionStartColumn===t.selectionStartColumn&&e.positionLineNumber===t.positionLineNumber&&e.positionColumn===t.positionColumn}getDirection(){return this.selectionStartLineNumber===this.startLineNumber&&this.selectionStartColumn===this.startColumn?0:1}setEndPosition(e,t){return 0===this.getDirection()?new s(this.startLineNumber,this.startColumn,e,t):new s(e,t,this.startLineNumber,this.startColumn)}getPosition(){return new r.y(this.positionLineNumber,this.positionColumn)}getSelectionStart(){return new r.y(this.selectionStartLineNumber,this.selectionStartColumn)}setStartPosition(e,t){return 0===this.getDirection()?new s(e,t,this.endLineNumber,this.endColumn):new s(this.endLineNumber,this.endColumn,e,t)}static fromPositions(e,t=e){return new s(e.lineNumber,e.column,t.lineNumber,t.column)}static fromRange(e,t){return 0===t?new s(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):new s(e.endLineNumber,e.endColumn,e.startLineNumber,e.startColumn)}static liftSelection(e){return new s(e.selectionStartLineNumber,e.selectionStartColumn,e.positionLineNumber,e.positionColumn)}static selectionsArrEqual(e,t){if(e&&!t||!e&&t)return!1;if(!e&&!t)return!0;if(e.length!==t.length)return!1;for(let n=0,r=e.length;n{"use strict";n.r(t),n.d(t,{SemanticTokensProviderStyling:()=>m,toMultilineTokens2:()=>p});n(5982);var r=n(5724),i=n(3511),s=n(3069),o=n(6677),a=n(4454);class l{static create(e,t){return new l(e,new c(t))}get startLineNumber(){return this._startLineNumber}get endLineNumber(){return this._endLineNumber}constructor(e,t){this._startLineNumber=e,this._tokens=t,this._endLineNumber=this._startLineNumber+this._tokens.getMaxDeltaLine()}toString(){return this._tokens.toString(this._startLineNumber)}_updateEndLineNumber(){this._endLineNumber=this._startLineNumber+this._tokens.getMaxDeltaLine()}isEmpty(){return this._tokens.isEmpty()}getLineTokens(e){return this._startLineNumber<=e&&e<=this._endLineNumber?this._tokens.getLineTokens(e-this._startLineNumber):null}getRange(){const e=this._tokens.getRange();return e?new o.Q(this._startLineNumber+e.startLineNumber,e.startColumn,this._startLineNumber+e.endLineNumber,e.endColumn):e}removeTokens(e){const t=e.startLineNumber-this._startLineNumber,n=e.endLineNumber-this._startLineNumber;this._startLineNumber+=this._tokens.removeTokens(t,e.startColumn-1,n,e.endColumn-1),this._updateEndLineNumber()}split(e){const t=e.startLineNumber-this._startLineNumber,n=e.endLineNumber-this._startLineNumber,[r,i,s]=this._tokens.split(t,e.startColumn-1,n,e.endColumn-1);return[new l(this._startLineNumber,r),new l(this._startLineNumber+s,i)]}applyEdit(e,t){const[n,r,i]=(0,a.W)(t);this.acceptEdit(e,n,r,i,t.length>0?t.charCodeAt(0):0)}acceptEdit(e,t,n,r,i){this._acceptDeleteRange(e),this._acceptInsertText(new s.y(e.startLineNumber,e.startColumn),t,n,r,i),this._updateEndLineNumber()}_acceptDeleteRange(e){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return;const t=e.startLineNumber-this._startLineNumber,n=e.endLineNumber-this._startLineNumber;if(n<0){const e=n-t;return void(this._startLineNumber-=e)}const r=this._tokens.getMaxDeltaLine();if(!(t>=r+1)){if(t<0&&n>=r+1)return this._startLineNumber=0,void this._tokens.clear();if(t<0){const r=-t;this._startLineNumber-=r,this._tokens.acceptDeleteRange(e.startColumn-1,0,0,n,e.endColumn-1)}else this._tokens.acceptDeleteRange(0,t,e.startColumn-1,n,e.endColumn-1)}}_acceptInsertText(e,t,n,r,i){if(0===t&&0===n)return;const s=e.lineNumber-this._startLineNumber;if(s<0)return void(this._startLineNumber+=t);s>=this._tokens.getMaxDeltaLine()+1||this._tokens.acceptInsertText(s,e.column-1,t,n,r,i)}}class c{constructor(e){this._tokens=e,this._tokenCount=e.length/4}toString(e){const t=[];for(let n=0;ne)){let i=r;for(;i>t&&this._getDeltaLine(i-1)===e;)i--;let s=r;for(;se||h===e&&d>=t)&&(he||o===e&&g>=t){if(oi?f-=i-n:f=n;else if(d===t&&g===n){if(!(d===r&&f>i)){c=!0;continue}f-=i-n}else if(di)){c=!0;continue}d=t,g=n,f=g+(f-i)}else if(d>r){if(0===a&&!c){l=o;break}d-=a}else{if(!(d===r&&g>=i))throw new Error("Not possible!");e&&0===d&&(g+=e,f+=e),d-=a,g-=i-n,f-=i-n}const p=4*l;s[p]=d,s[p+1]=g,s[p+2]=f,s[p+3]=m,l++}this._tokenCount=l}acceptInsertText(e,t,n,r,i,s){const o=0===n&&1===r&&(s>=48&&s<=57||s>=65&&s<=90||s>=97&&s<=122),a=this._tokens,l=this._tokenCount;for(let c=0;c=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},g=function(e,t){return function(n,r){t(n,r,e)}};const f=!1;let m=class{constructor(e,t,n,r){this._legend=e,this._themeService=t,this._languageService=n,this._logService=r,this._hasWarnedOverlappingTokens=!1,this._hasWarnedInvalidLengthTokens=!1,this._hasWarnedInvalidEditStart=!1,this._hashTable=new _}getMetadata(e,t,n){const r=this._languageService.languageIdCodec.encodeLanguageId(n),i=this._hashTable.get(e,t,r);let s;if(i)s=i.metadata;else{let i=this._legend.tokenTypes[e];const o=[];if(i){let e=t;for(let t=0;e>0&&t>=1;f;const r=this._themeService.getColorTheme().getTokenStyleMetadata(i,o,n);if("undefined"===typeof r)s=2147483647;else{if(s=0,"undefined"!==typeof r.italic){s|=1|(r.italic?1:0)<<11}if("undefined"!==typeof r.bold){s|=2|(r.bold?2:0)<<11}if("undefined"!==typeof r.underline){s|=4|(r.underline?4:0)<<11}if("undefined"!==typeof r.strikethrough){s|=8|(r.strikethrough?8:0)<<11}if(r.foreground){s|=16|r.foreground<<15}0===s&&(s=2147483647)}}else s=2147483647,i="not-in-legend";this._hashTable.add(e,t,r,s)}return s}warnOverlappingSemanticTokens(e,t){this._hasWarnedOverlappingTokens||(this._hasWarnedOverlappingTokens=!0,this._logService.warn(`Overlapping semantic tokens detected at lineNumber ${e}, column ${t}`))}warnInvalidLengthSemanticTokens(e,t){this._hasWarnedInvalidLengthTokens||(this._hasWarnedInvalidLengthTokens=!0,this._logService.warn(`Semantic token with invalid length detected at lineNumber ${e}, column ${t}`))}warnInvalidEditStart(e,t,n,r,i){this._hasWarnedInvalidEditStart||(this._hasWarnedInvalidEditStart=!0,this._logService.warn(`Invalid semantic tokens edit detected (previousResultId: ${e}, resultId: ${t}) at edit #${n}: The provided start offset ${r} is outside the previous data (length ${i}).`))}};function p(e,t,n){const r=e.data,i=e.data.length/5|0,s=Math.max(Math.ceil(i/1024),400),o=[];let a=0,c=1,h=0;for(;ae&&0===r[5*t];)t--;if(t-1===e){let e=u;for(;e+1l)t.warnOverlappingSemanticTokens(o,l+1);else{const e=t.getMetadata(b,_,n);2147483647!==e&&(0===f&&(f=o),d[g]=o-f,d[g+1]=l,d[g+2]=u,d[g+3]=e,g+=4,m=o,p=u)}c=o,h=l,a++}g!==d.length&&(d=d.subarray(0,g));const b=l.create(f,d);o.push(b)}return o}m=d([g(1,r.Gy),g(2,u.L),g(3,i.rr)],m);class b{constructor(e,t,n,r){this.tokenTypeIndex=e,this.tokenModifierSet=t,this.languageId=n,this.metadata=r,this.next=null}}class _{static{this._SIZES=[3,7,13,31,61,127,251,509,1021,2039,4093,8191,16381,32749,65521,131071,262139,524287,1048573,2097143]}constructor(){this._elementsCount=0,this._currentLengthIndex=0,this._currentLength=_._SIZES[this._currentLengthIndex],this._growCount=Math.round(this._currentLengthIndex+1<_._SIZES.length?2/3*this._currentLength:0),this._elements=[],_._nullOutEntries(this._elements,this._currentLength)}static _nullOutEntries(e,t){for(let n=0;n=this._growCount){const e=this._elements;this._currentLengthIndex++,this._currentLength=_._SIZES[this._currentLengthIndex],this._growCount=Math.round(this._currentLengthIndex+1<_._SIZES.length?2/3*this._currentLength:0),this._elements=[],_._nullOutEntries(this._elements,this._currentLength);for(const t of e){let e=t;for(;e;){const t=e.next;e.next=null,this._add(e),e=t}}}this._add(new b(e,t,n,r))}_add(e){const t=this._hashFunc(e.tokenTypeIndex,e.tokenModifierSet,e.languageId);e.next=this._elements[t],this._elements[t]=e}}},5600:(e,t,n)=>{"use strict";n.d(t,{e2:()=>o,sN:()=>i,v7:()=>h});var r=n(1508);function i(e,t){switch(typeof e){case"object":return null===e?s(349,t):Array.isArray(e)?(n=e,r=s(104579,r=t),n.reduce(((e,t)=>i(t,e)),r)):function(e,t){return t=s(181387,t),Object.keys(e).sort().reduce(((t,n)=>(t=o(n,t),i(e[n],t))),t)}(e,t);case"string":return o(e,t);case"boolean":return function(e,t){return s(e?433:863,t)}(e,t);case"number":return s(e,t);case"undefined":return s(937,t);default:return s(617,t)}var n,r}function s(e,t){return(t<<5)-t+e|0}function o(e,t){t=s(149417,t);for(let n=0,r=e.length;n>>r)>>>0}function l(e,t=0,n=e.byteLength,r=0){for(let i=0;ie.toString(16).padStart(2,"0"))).join(""):function(e,t,n="0"){for(;e.length>>0).toString(16),t/4)}class h{static{this._bigBlock32=new DataView(new ArrayBuffer(320))}constructor(){this._h0=1732584193,this._h1=4023233417,this._h2=2562383102,this._h3=271733878,this._h4=3285377520,this._buff=new Uint8Array(67),this._buffDV=new DataView(this._buff.buffer),this._buffLen=0,this._totalLen=0,this._leftoverHighSurrogate=0,this._finished=!1}update(e){const t=e.length;if(0===t)return;const n=this._buff;let i,s,o=this._buffLen,a=this._leftoverHighSurrogate;for(0!==a?(i=a,s=-1,a=0):(i=e.charCodeAt(0),s=0);;){let l=i;if(r.pc(i)){if(!(s+1>>6,e[t++]=128|(63&n)>>>0):n<65536?(e[t++]=224|(61440&n)>>>12,e[t++]=128|(4032&n)>>>6,e[t++]=128|(63&n)>>>0):(e[t++]=240|(1835008&n)>>>18,e[t++]=128|(258048&n)>>>12,e[t++]=128|(4032&n)>>>6,e[t++]=128|(63&n)>>>0),t>=64&&(this._step(),t-=64,this._totalLen+=64,e[0]=e[64],e[1]=e[65],e[2]=e[66]),t}digest(){return this._finished||(this._finished=!0,this._leftoverHighSurrogate&&(this._leftoverHighSurrogate=0,this._buffLen=this._push(this._buff,this._buffLen,65533)),this._totalLen+=this._buffLen,this._wrapUp()),c(this._h0)+c(this._h1)+c(this._h2)+c(this._h3)+c(this._h4)}_wrapUp(){this._buff[this._buffLen++]=128,l(this._buff,this._buffLen),this._buffLen>56&&(this._step(),l(this._buff));const e=8*this._totalLen;this._buffDV.setUint32(56,Math.floor(e/4294967296),!1),this._buffDV.setUint32(60,e%4294967296,!1),this._step()}_step(){const e=h._bigBlock32,t=this._buffDV;for(let a=0;a<64;a+=4)e.setUint32(a,t.getUint32(a,!1),!1);for(let h=64;h<320;h+=4)e.setUint32(h,a(e.getUint32(h-12,!1)^e.getUint32(h-32,!1)^e.getUint32(h-56,!1)^e.getUint32(h-64,!1),1),!1);let n,r,i,s=this._h0,o=this._h1,l=this._h2,c=this._h3,u=this._h4;for(let h=0;h<80;h++)h<20?(n=o&l|~o&c,r=1518500249):h<40?(n=o^l^c,r=1859775393):h<60?(n=o&l|o&c|l&c,r=2400959708):(n=o^l^c,r=3395469782),i=a(s,5)+n+u+r+e.getUint32(4*h,!1)&4294967295,u=c,c=l,l=a(o,30),o=s,s=i;this._h0=this._h0+s&4294967295,this._h1=this._h1+o&4294967295,this._h2=this._h2+l&4294967295,this._h3=this._h3+c&4294967295,this._h4=this._h4+u&4294967295}}},5628:(e,t,n)=>{"use strict";n.r(t),n.d(t,{getIconClasses:()=>d});var r,i=n(6456),s=n(9403),o=n(9400),a=n(3941);!function(e){e[e.FILE=0]="FILE",e[e.FOLDER=1]="FOLDER",e[e.ROOT_FOLDER=2]="ROOT_FOLDER"}(r||(r={}));var l,c,h=n(9493);!function(e){e.isThemeColor=function(e){return e&&"object"===typeof e&&"string"===typeof e.id}}(l||(l={})),function(e){e.iconNameSegment="[A-Za-z0-9]+",e.iconNameExpression="[A-Za-z0-9-]+",e.iconModifierExpression="~[A-Za-z]+",e.iconNameCharacter="[A-Za-z0-9~-]";const t=new RegExp(`^(${e.iconNameExpression})(${e.iconModifierExpression})?$`);function n(e){const r=t.exec(e.id);if(!r)return n(h.W.error);const[,i,s]=r,o=["codicon","codicon-"+i];return s&&o.push("codicon-modifier-"+s.substring(1)),o}e.asClassNameArray=n,e.asClassName=function(e){return n(e).join(" ")},e.asCSSSelector=function(e){return"."+n(e).join(".")},e.isThemeIcon=function(e){return e&&"object"===typeof e&&"string"===typeof e.id&&("undefined"===typeof e.color||l.isThemeColor(e.color))};const r=new RegExp(`^\\$\\((${e.iconNameExpression}(?:${e.iconModifierExpression})?)\\)$`);e.fromString=function(e){const t=r.exec(e);if(!t)return;const[,n]=t;return{id:n}},e.fromId=function(e){return{id:e}},e.modify=function(e,t){let n=e.id;const r=n.lastIndexOf("~");return-1!==r&&(n=n.substring(0,r)),t&&(n=`${n}~${t}`),{id:n}},e.getModifier=function(e){const t=e.id.lastIndexOf("~");if(-1!==t)return e.id.substring(t+1)},e.isEqual=function(e,t){return e.id===t.id&&e.color?.id===t.color?.id}}(c||(c={}));const u=/(?:\/|^)(?:([^\/]+)\/)?([^\/]+)$/;function d(e,t,n,l,h){if(c.isThemeIcon(h))return[`codicon-${h.id}`,"predefined-file-icon"];if(o.r.isUri(h))return[];const d=l===r.ROOT_FOLDER?["rootfolder-icon"]:l===r.FOLDER?["folder-icon"]:["file-icon"];if(n){let o;if(n.scheme===i.ny.data){o=s.B6.parseMetaData(n).get(s.B6.META_DATA_LABEL)}else{const e=n.path.match(u);e?(o=g(e[2].toLowerCase()),e[1]&&d.push(`${g(e[1].toLowerCase())}-name-dir-icon`)):o=g(n.authority.toLowerCase())}if(l===r.ROOT_FOLDER)d.push(`${o}-root-name-folder-icon`);else if(l===r.FOLDER)d.push(`${o}-name-folder-icon`);else{if(o){if(d.push(`${o}-name-file-icon`),d.push("name-file-icon"),o.length<=255){const e=o.split(".");for(let t=1;t{"use strict";n.d(t,{Gy:()=>l,zy:()=>u,Yf:()=>c});var r,i=n(1234),s=n(1484),o=n(3591),a=n(6359);!function(e){e.DARK="dark",e.LIGHT="light",e.HIGH_CONTRAST_DARK="hcDark",e.HIGH_CONTRAST_LIGHT="hcLight"}(r||(r={}));const l=(0,o.u1)("themeService");function c(e){return{id:e}}const h=new class{constructor(){this.themingParticipants=[],this.themingParticipants=[],this.onThemingParticipantAddedEmitter=new i.vl}onColorThemeChange(e){return this.themingParticipants.push(e),this.onThemingParticipantAddedEmitter.fire(e),(0,s.s)((()=>{const t=this.themingParticipants.indexOf(e);this.themingParticipants.splice(t,1)}))}getThemingParticipants(){return this.themingParticipants}};function u(e){return h.onColorThemeChange(e)}a.O.add("base.contributions.theming",h);s.jG},5845:(e,t,n)=>{"use strict";n.d(t,{buw:()=>S,b1q:()=>w,YtV:()=>I,Ubg:()=>q,IIb:()=>z,pOz:()=>V,whs:()=>B,Stt:()=>P,Hng:()=>F,yLC:()=>le,KoI:()=>oe,uMG:()=>ae,x1A:()=>u});var r=n(6782),i=n(1940),s=n(7661),o=n(1234),a=n(8748),l=n(6359),c=n(8209);const h=new class{constructor(){this._onDidChangeSchema=new o.vl,this.onDidChangeSchema=this._onDidChangeSchema.event,this.colorSchema={type:"object",properties:{}},this.colorReferenceSchema={type:"string",enum:[],enumDescriptions:[]},this.colorsById={}}registerColor(e,t,n,r=!1,i){const s={id:e,description:n,defaults:t,needsTransparency:r,deprecationMessage:i};this.colorsById[e]=s;const o={type:"string",format:"color-hex",defaultSnippets:[{body:"${1:#ff0000}"}]};return i&&(o.deprecationMessage=i),r&&(o.pattern="^#(?:(?[0-9a-fA-f]{3}[0-9a-eA-E])|(?:[0-9a-fA-F]{6}(?:(?![fF]{2})(?:[0-9a-fA-F]{2}))))?$",o.patternErrorMessage=c.kg("transparecyRequired","This color must be transparent or it will obscure content")),this.colorSchema.properties[e]={description:n,oneOf:[o,{type:"string",const:"default",description:c.kg("useDefault","Use the default color.")}]},this.colorReferenceSchema.enum.push(e),this.colorReferenceSchema.enumDescriptions.push(n),this._onDidChangeSchema.fire(),e}getColors(){return Object.keys(this.colorsById).map((e=>this.colorsById[e]))}resolveDefaultColor(e,t){const n=this.colorsById[e];if(n?.defaults){return b(null!==(r=n.defaults)&&"object"===typeof r&&"light"in r&&"dark"in r?n.defaults[t.type]:n.defaults,t)}var r}getColorSchema(){return this.colorSchema}toString(){return Object.keys(this.colorsById).sort(((e,t)=>{const n=-1===e.indexOf(".")?0:1,r=-1===t.indexOf(".")?0:1;return n!==r?n-r:e.localeCompare(t)})).map((e=>`- \`${e}\`: ${this.colorsById[e].description}`)).join("\n")}};function u(e,t,n,r,i){return h.registerColor(e,t,n,r,i)}function d(e,t){return{op:0,value:e,factor:t}}function g(e,t){return{op:1,value:e,factor:t}}function f(e,t){return{op:2,value:e,factor:t}}function m(...e){return{op:4,values:e}}function p(e,t,n,r){return{op:5,value:e,background:t,factor:n,transparency:r}}function b(e,t){if(null!==e)return"string"===typeof e?"#"===e[0]?s.Q1.fromHex(e):t.getColor(e):e instanceof s.Q1?e:"object"===typeof e?function(e,t){switch(e.op){case 0:return b(e.value,t)?.darken(e.factor);case 1:return b(e.value,t)?.lighten(e.factor);case 2:return b(e.value,t)?.transparent(e.factor);case 3:{const n=b(e.background,t);return n?b(e.value,t)?.makeOpaque(n):b(e.value,t)}case 4:for(const n of e.values){const e=b(n,t);if(e)return e}return;case 6:return b(t.defines(e.if)?e.then:e.else,t);case 5:{const n=b(e.value,t);if(!n)return;const r=b(e.background,t);return r?n.isDarkerThan(r)?s.Q1.getLighterColor(n,r,e.factor).transparent(e.transparency):s.Q1.getDarkerColor(n,r,e.factor).transparent(e.transparency):n.transparent(e.factor*e.transparency)}default:throw(0,r.xb)(e)}}(e,t):void 0}l.O.add("base.contributions.colors",h);const _="vscode://schemas/workbench-colors",k=l.O.as(a.F.JSONContribution);k.registerSchema(_,h.getColorSchema());const v=new i.uC((()=>k.notifySchemaChanged(_)),200);h.onDidChangeSchema((()=>{v.isScheduled()||v.schedule()}));const C=u("foreground",{dark:"#CCCCCC",light:"#616161",hcDark:"#FFFFFF",hcLight:"#292929"},c.kg("foreground","Overall foreground color. This color is only used if not overridden by a component.")),y=(u("disabledForeground",{dark:"#CCCCCC80",light:"#61616180",hcDark:"#A5A5A5",hcLight:"#7F7F7F"},c.kg("disabledForeground","Overall foreground for disabled elements. This color is only used if not overridden by a component.")),u("errorForeground",{dark:"#F48771",light:"#A1260D",hcDark:"#F48771",hcLight:"#B5200D"},c.kg("errorForeground","Overall foreground color for error messages. This color is only used if not overridden by a component.")),u("descriptionForeground",{light:"#717171",dark:f(C,.7),hcDark:f(C,.7),hcLight:f(C,.7)},c.kg("descriptionForeground","Foreground color for description text providing additional information, for example for a label.")),u("icon.foreground",{dark:"#C5C5C5",light:"#424242",hcDark:"#FFFFFF",hcLight:"#292929"},c.kg("iconForeground","The default color for icons in the workbench."))),L=u("focusBorder",{dark:"#007FD4",light:"#0090F1",hcDark:"#F38518",hcLight:"#006BBD"},c.kg("focusBorder","Overall border color for focused elements. This color is only used if not overridden by a component.")),w=u("contrastBorder",{light:null,dark:null,hcDark:"#6FC3DF",hcLight:"#0F4A85"},c.kg("contrastBorder","An extra border around elements to separate them from others for greater contrast.")),S=u("contrastActiveBorder",{light:null,dark:null,hcDark:L,hcLight:L},c.kg("activeContrastBorder","An extra border around active elements to separate them from others for greater contrast.")),x=(u("selection.background",null,c.kg("selectionBackground","The background color of text selections in the workbench (e.g. for input fields or text areas). Note that this does not apply to selections within the editor.")),u("textLink.foreground",{light:"#006AB1",dark:"#3794FF",hcDark:"#21A6FF",hcLight:"#0F4A85"},c.kg("textLinkForeground","Foreground color for links in text.")),u("textLink.activeForeground",{light:"#006AB1",dark:"#3794FF",hcDark:"#21A6FF",hcLight:"#0F4A85"},c.kg("textLinkActiveForeground","Foreground color for links in text when clicked on and on mouse hover.")),u("textSeparator.foreground",{light:"#0000002e",dark:"#ffffff2e",hcDark:s.Q1.black,hcLight:"#292929"},c.kg("textSeparatorForeground","Color for text separators.")),u("textPreformat.foreground",{light:"#A31515",dark:"#D7BA7D",hcDark:"#000000",hcLight:"#FFFFFF"},c.kg("textPreformatForeground","Foreground color for preformatted text segments.")),u("textPreformat.background",{light:"#0000001A",dark:"#FFFFFF1A",hcDark:"#FFFFFF",hcLight:"#09345f"},c.kg("textPreformatBackground","Background color for preformatted text segments.")),u("textBlockQuote.background",{light:"#f2f2f2",dark:"#222222",hcDark:null,hcLight:"#F2F2F2"},c.kg("textBlockQuoteBackground","Background color for block quotes in text.")),u("textBlockQuote.border",{light:"#007acc80",dark:"#007acc80",hcDark:s.Q1.white,hcLight:"#292929"},c.kg("textBlockQuoteBorder","Border color for block quotes in text.")),u("textCodeBlock.background",{light:"#dcdcdc66",dark:"#0a0a0a66",hcDark:s.Q1.black,hcLight:"#F2F2F2"},c.kg("textCodeBlockBackground","Background color for code blocks in text.")),u("sash.hoverBorder",L,c.kg("sashActiveBorder","Border color of active sashes.")),u("badge.background",{dark:"#4D4D4D",light:"#C4C4C4",hcDark:s.Q1.black,hcLight:"#0F4A85"},c.kg("badgeBackground","Badge background color. Badges are small information labels, e.g. for search results count."))),E=(u("badge.foreground",{dark:s.Q1.white,light:"#333",hcDark:s.Q1.white,hcLight:s.Q1.white},c.kg("badgeForeground","Badge foreground color. Badges are small information labels, e.g. for search results count.")),u("scrollbar.shadow",{dark:"#000000",light:"#DDDDDD",hcDark:null,hcLight:null},c.kg("scrollbarShadow","Scrollbar shadow to indicate that the view is scrolled."))),N=u("scrollbarSlider.background",{dark:s.Q1.fromHex("#797979").transparent(.4),light:s.Q1.fromHex("#646464").transparent(.4),hcDark:f(w,.6),hcLight:f(w,.4)},c.kg("scrollbarSliderBackground","Scrollbar slider background color.")),T=u("scrollbarSlider.hoverBackground",{dark:s.Q1.fromHex("#646464").transparent(.7),light:s.Q1.fromHex("#646464").transparent(.7),hcDark:f(w,.8),hcLight:f(w,.8)},c.kg("scrollbarSliderHoverBackground","Scrollbar slider background color when hovering.")),A=u("scrollbarSlider.activeBackground",{dark:s.Q1.fromHex("#BFBFBF").transparent(.4),light:s.Q1.fromHex("#000000").transparent(.6),hcDark:w,hcLight:w},c.kg("scrollbarSliderActiveBackground","Scrollbar slider background color when clicked on.")),I=(u("progressBar.background",{dark:s.Q1.fromHex("#0E70C0"),light:s.Q1.fromHex("#0E70C0"),hcDark:w,hcLight:w},c.kg("progressBarBackground","Background color of the progress bar that can show for long running operations.")),u("editor.background",{light:"#ffffff",dark:"#1E1E1E",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("editorBackground","Editor background color."))),O=(u("editor.foreground",{light:"#333333",dark:"#BBBBBB",hcDark:s.Q1.white,hcLight:C},c.kg("editorForeground","Editor default foreground color.")),u("editorStickyScroll.background",I,c.kg("editorStickyScrollBackground","Background color of sticky scroll in the editor")),u("editorStickyScrollHover.background",{dark:"#2A2D2E",light:"#F0F0F0",hcDark:null,hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("editorStickyScrollHoverBackground","Background color of sticky scroll on hover in the editor")),u("editorStickyScroll.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("editorStickyScrollBorder","Border color of sticky scroll in the editor")),u("editorStickyScroll.shadow",E,c.kg("editorStickyScrollShadow"," Shadow color of sticky scroll in the editor")),u("editorWidget.background",{dark:"#252526",light:"#F3F3F3",hcDark:"#0C141F",hcLight:s.Q1.white},c.kg("editorWidgetBackground","Background color of editor widgets, such as find/replace."))),M=u("editorWidget.foreground",C,c.kg("editorWidgetForeground","Foreground color of editor widgets, such as find/replace.")),R=u("editorWidget.border",{dark:"#454545",light:"#C8C8C8",hcDark:w,hcLight:w},c.kg("editorWidgetBorder","Border color of editor widgets. The color is only used if the widget chooses to have a border and if the color is not overridden by a widget.")),D=(u("editorWidget.resizeBorder",null,c.kg("editorWidgetResizeBorder","Border color of the resize bar of editor widgets. The color is only used if the widget chooses to have a resize border and if the color is not overridden by a widget.")),u("editorError.background",null,c.kg("editorError.background","Background color of error text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorError.foreground",{dark:"#F14C4C",light:"#E51400",hcDark:"#F48771",hcLight:"#B5200D"},c.kg("editorError.foreground","Foreground color of error squigglies in the editor."))),B=(u("editorError.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#E47777").transparent(.8),hcLight:"#B5200D"},c.kg("errorBorder","If set, color of double underlines for errors in the editor.")),u("editorWarning.background",null,c.kg("editorWarning.background","Background color of warning text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0)),F=u("editorWarning.foreground",{dark:"#CCA700",light:"#BF8803",hcDark:"#FFD370",hcLight:"#895503"},c.kg("editorWarning.foreground","Foreground color of warning squigglies in the editor.")),P=u("editorWarning.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#FFCC00").transparent(.8),hcLight:s.Q1.fromHex("#FFCC00").transparent(.8)},c.kg("warningBorder","If set, color of double underlines for warnings in the editor.")),V=(u("editorInfo.background",null,c.kg("editorInfo.background","Background color of info text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorInfo.foreground",{dark:"#3794FF",light:"#1a85ff",hcDark:"#3794FF",hcLight:"#1a85ff"},c.kg("editorInfo.foreground","Foreground color of info squigglies in the editor."))),z=u("editorInfo.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#3794FF").transparent(.8),hcLight:"#292929"},c.kg("infoBorder","If set, color of double underlines for infos in the editor.")),j=(u("editorHint.foreground",{dark:s.Q1.fromHex("#eeeeee").transparent(.7),light:"#6c6c6c",hcDark:null,hcLight:null},c.kg("editorHint.foreground","Foreground color of hint squigglies in the editor.")),u("editorHint.border",{dark:null,light:null,hcDark:s.Q1.fromHex("#eeeeee").transparent(.8),hcLight:"#292929"},c.kg("hintBorder","If set, color of double underlines for hints in the editor.")),u("editorLink.activeForeground",{dark:"#4E94CE",light:s.Q1.blue,hcDark:s.Q1.cyan,hcLight:"#292929"},c.kg("activeLinkForeground","Color of active links.")),u("editor.selectionBackground",{light:"#ADD6FF",dark:"#264F78",hcDark:"#f3f518",hcLight:"#0F4A85"},c.kg("editorSelectionBackground","Color of the editor selection."))),q=(u("editor.selectionForeground",{light:null,dark:null,hcDark:"#000000",hcLight:s.Q1.white},c.kg("editorSelectionForeground","Color of the selected text for high contrast.")),u("editor.inactiveSelectionBackground",{light:f(j,.5),dark:f(j,.5),hcDark:f(j,.7),hcLight:f(j,.5)},c.kg("editorInactiveSelection","Color of the selection in an inactive editor. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.selectionHighlightBackground",{light:p(j,I,.3,.6),dark:p(j,I,.3,.6),hcDark:null,hcLight:null},c.kg("editorSelectionHighlight","Color for regions with the same content as the selection. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.selectionHighlightBorder",{light:null,dark:null,hcDark:S,hcLight:S},c.kg("editorSelectionHighlightBorder","Border color for regions with the same content as the selection.")),u("editor.findMatchBackground",{light:"#A8AC94",dark:"#515C6A",hcDark:null,hcLight:null},c.kg("editorFindMatch","Color of the current search match.")),u("editor.findMatchForeground",null,c.kg("editorFindMatchForeground","Text color of the current search match.")),u("editor.findMatchHighlightBackground",{light:"#EA5C0055",dark:"#EA5C0055",hcDark:null,hcLight:null},c.kg("findMatchHighlight","Color of the other search matches. The color must not be opaque so as not to hide underlying decorations."),!0)),W=(u("editor.findMatchHighlightForeground",null,c.kg("findMatchHighlightForeground","Foreground color of the other search matches."),!0),u("editor.findRangeHighlightBackground",{dark:"#3a3d4166",light:"#b4b4b44d",hcDark:null,hcLight:null},c.kg("findRangeHighlight","Color of the range limiting the search. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.findMatchBorder",{light:null,dark:null,hcDark:S,hcLight:S},c.kg("editorFindMatchBorder","Border color of the current search match.")),u("editor.findMatchHighlightBorder",{light:null,dark:null,hcDark:S,hcLight:S},c.kg("findMatchHighlightBorder","Border color of the other search matches."))),U=(u("editor.findRangeHighlightBorder",{dark:null,light:null,hcDark:f(S,.4),hcLight:f(S,.4)},c.kg("findRangeHighlightBorder","Border color of the range limiting the search. The color must not be opaque so as not to hide underlying decorations."),!0),u("editor.hoverHighlightBackground",{light:"#ADD6FF26",dark:"#264f7840",hcDark:"#ADD6FF26",hcLight:null},c.kg("hoverHighlight","Highlight below the word for which a hover is shown. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorHoverWidget.background",O,c.kg("hoverBackground","Background color of the editor hover."))),$=(u("editorHoverWidget.foreground",M,c.kg("hoverForeground","Foreground color of the editor hover.")),u("editorHoverWidget.border",R,c.kg("hoverBorder","Border color of the editor hover.")),u("editorHoverWidget.statusBarBackground",{dark:g(U,.2),light:d(U,.05),hcDark:O,hcLight:O},c.kg("statusBarBackground","Background color of the editor hover status bar.")),u("editorInlayHint.foreground",{dark:"#969696",light:"#969696",hcDark:s.Q1.white,hcLight:s.Q1.black},c.kg("editorInlayHintForeground","Foreground color of inline hints"))),H=u("editorInlayHint.background",{dark:f(x,.1),light:f(x,.1),hcDark:f(s.Q1.white,.1),hcLight:f(x,.1)},c.kg("editorInlayHintBackground","Background color of inline hints")),K=(u("editorInlayHint.typeForeground",$,c.kg("editorInlayHintForegroundTypes","Foreground color of inline hints for types")),u("editorInlayHint.typeBackground",H,c.kg("editorInlayHintBackgroundTypes","Background color of inline hints for types")),u("editorInlayHint.parameterForeground",$,c.kg("editorInlayHintForegroundParameter","Foreground color of inline hints for parameters")),u("editorInlayHint.parameterBackground",H,c.kg("editorInlayHintBackgroundParameter","Background color of inline hints for parameters")),u("editorLightBulb.foreground",{dark:"#FFCC00",light:"#DDB100",hcDark:"#FFCC00",hcLight:"#007ACC"},c.kg("editorLightBulbForeground","The color used for the lightbulb actions icon."))),G=(u("editorLightBulbAutoFix.foreground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},c.kg("editorLightBulbAutoFixForeground","The color used for the lightbulb auto fix actions icon.")),u("editorLightBulbAi.foreground",K,c.kg("editorLightBulbAiForeground","The color used for the lightbulb AI icon.")),u("editor.snippetTabstopHighlightBackground",{dark:new s.Q1(new s.bU(124,124,124,.3)),light:new s.Q1(new s.bU(10,50,100,.2)),hcDark:new s.Q1(new s.bU(124,124,124,.3)),hcLight:new s.Q1(new s.bU(10,50,100,.2))},c.kg("snippetTabstopHighlightBackground","Highlight background color of a snippet tabstop.")),u("editor.snippetTabstopHighlightBorder",null,c.kg("snippetTabstopHighlightBorder","Highlight border color of a snippet tabstop.")),u("editor.snippetFinalTabstopHighlightBackground",null,c.kg("snippetFinalTabstopHighlightBackground","Highlight background color of the final tabstop of a snippet.")),u("editor.snippetFinalTabstopHighlightBorder",{dark:"#525252",light:new s.Q1(new s.bU(10,50,100,.5)),hcDark:"#525252",hcLight:"#292929"},c.kg("snippetFinalTabstopHighlightBorder","Highlight border color of the final tabstop of a snippet.")),new s.Q1(new s.bU(155,185,85,.2))),Q=new s.Q1(new s.bU(255,0,0,.2)),J=(u("diffEditor.insertedTextBackground",{dark:"#9ccc2c33",light:"#9ccc2c40",hcDark:null,hcLight:null},c.kg("diffEditorInserted","Background color for text that got inserted. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditor.removedTextBackground",{dark:"#ff000033",light:"#ff000033",hcDark:null,hcLight:null},c.kg("diffEditorRemoved","Background color for text that got removed. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditor.insertedLineBackground",{dark:G,light:G,hcDark:null,hcLight:null},c.kg("diffEditorInsertedLines","Background color for lines that got inserted. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditor.removedLineBackground",{dark:Q,light:Q,hcDark:null,hcLight:null},c.kg("diffEditorRemovedLines","Background color for lines that got removed. The color must not be opaque so as not to hide underlying decorations."),!0),u("diffEditorGutter.insertedLineBackground",null,c.kg("diffEditorInsertedLineGutter","Background color for the margin where lines got inserted.")),u("diffEditorGutter.removedLineBackground",null,c.kg("diffEditorRemovedLineGutter","Background color for the margin where lines got removed.")),u("diffEditorOverview.insertedForeground",null,c.kg("diffEditorOverviewInserted","Diff overview ruler foreground for inserted content.")),u("diffEditorOverview.removedForeground",null,c.kg("diffEditorOverviewRemoved","Diff overview ruler foreground for removed content.")),u("diffEditor.insertedTextBorder",{dark:null,light:null,hcDark:"#33ff2eff",hcLight:"#374E06"},c.kg("diffEditorInsertedOutline","Outline color for the text that got inserted.")),u("diffEditor.removedTextBorder",{dark:null,light:null,hcDark:"#FF008F",hcLight:"#AD0707"},c.kg("diffEditorRemovedOutline","Outline color for text that got removed.")),u("diffEditor.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("diffEditorBorder","Border color between the two text editors.")),u("diffEditor.diagonalFill",{dark:"#cccccc33",light:"#22222233",hcDark:null,hcLight:null},c.kg("diffDiagonalFill","Color of the diff editor's diagonal fill. The diagonal fill is used in side-by-side diff views.")),u("diffEditor.unchangedRegionBackground","sideBar.background",c.kg("diffEditor.unchangedRegionBackground","The background color of unchanged blocks in the diff editor.")),u("diffEditor.unchangedRegionForeground","foreground",c.kg("diffEditor.unchangedRegionForeground","The foreground color of unchanged blocks in the diff editor.")),u("diffEditor.unchangedCodeBackground",{dark:"#74747429",light:"#b8b8b829",hcDark:null,hcLight:null},c.kg("diffEditor.unchangedCodeBackground","The background color of unchanged code in the diff editor.")),u("widget.shadow",{dark:f(s.Q1.black,.36),light:f(s.Q1.black,.16),hcDark:null,hcLight:null},c.kg("widgetShadow","Shadow color of widgets such as find/replace inside the editor."))),X=(u("widget.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("widgetBorder","Border color of widgets such as find/replace inside the editor.")),u("toolbar.hoverBackground",{dark:"#5a5d5e50",light:"#b8b8b850",hcDark:null,hcLight:null},c.kg("toolbarHoverBackground","Toolbar background when hovering over actions using the mouse"))),Y=(u("toolbar.hoverOutline",{dark:null,light:null,hcDark:S,hcLight:S},c.kg("toolbarHoverOutline","Toolbar outline when hovering over actions using the mouse")),u("toolbar.activeBackground",{dark:g(X,.1),light:d(X,.1),hcDark:null,hcLight:null},c.kg("toolbarActiveBackground","Toolbar background when holding the mouse over actions")),u("breadcrumb.foreground",f(C,.8),c.kg("breadcrumbsFocusForeground","Color of focused breadcrumb items.")),u("breadcrumb.background",I,c.kg("breadcrumbsBackground","Background color of breadcrumb items.")),u("breadcrumb.focusForeground",{light:d(C,.2),dark:g(C,.1),hcDark:g(C,.1),hcLight:g(C,.1)},c.kg("breadcrumbsFocusForeground","Color of focused breadcrumb items.")),u("breadcrumb.activeSelectionForeground",{light:d(C,.2),dark:g(C,.1),hcDark:g(C,.1),hcLight:g(C,.1)},c.kg("breadcrumbsSelectedForeground","Color of selected breadcrumb items.")),u("breadcrumbPicker.background",O,c.kg("breadcrumbsSelectedBackground","Background color of breadcrumb item picker.")),s.Q1.fromHex("#40C8AE").transparent(.5)),Z=s.Q1.fromHex("#40A6FF").transparent(.5),ee=s.Q1.fromHex("#606060").transparent(.4),te=u("merge.currentHeaderBackground",{dark:Y,light:Y,hcDark:null,hcLight:null},c.kg("mergeCurrentHeaderBackground","Current header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),ne=(u("merge.currentContentBackground",f(te,.4),c.kg("mergeCurrentContentBackground","Current content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),u("merge.incomingHeaderBackground",{dark:Z,light:Z,hcDark:null,hcLight:null},c.kg("mergeIncomingHeaderBackground","Incoming header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0)),re=(u("merge.incomingContentBackground",f(ne,.4),c.kg("mergeIncomingContentBackground","Incoming content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),u("merge.commonHeaderBackground",{dark:ee,light:ee,hcDark:null,hcLight:null},c.kg("mergeCommonHeaderBackground","Common ancestor header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0)),ie=(u("merge.commonContentBackground",f(re,.4),c.kg("mergeCommonContentBackground","Common ancestor content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),u("merge.border",{dark:null,light:null,hcDark:"#C3DF6F",hcLight:"#007ACC"},c.kg("mergeBorder","Border color on headers and the splitter in inline merge-conflicts."))),se=(u("editorOverviewRuler.currentContentForeground",{dark:f(te,1),light:f(te,1),hcDark:ie,hcLight:ie},c.kg("overviewRulerCurrentContentForeground","Current overview ruler foreground for inline merge-conflicts.")),u("editorOverviewRuler.incomingContentForeground",{dark:f(ne,1),light:f(ne,1),hcDark:ie,hcLight:ie},c.kg("overviewRulerIncomingContentForeground","Incoming overview ruler foreground for inline merge-conflicts.")),u("editorOverviewRuler.commonContentForeground",{dark:f(re,1),light:f(re,1),hcDark:ie,hcLight:ie},c.kg("overviewRulerCommonContentForeground","Common ancestor overview ruler foreground for inline merge-conflicts.")),u("editorOverviewRuler.findMatchForeground",{dark:"#d186167e",light:"#d186167e",hcDark:"#AB5A00",hcLight:"#AB5A00"},c.kg("overviewRulerFindMatchForeground","Overview ruler marker color for find matches. The color must not be opaque so as not to hide underlying decorations."),!0),u("editorOverviewRuler.selectionHighlightForeground","#A0A0A0CC",c.kg("overviewRulerSelectionHighlightForeground","Overview ruler marker color for selection highlights. The color must not be opaque so as not to hide underlying decorations."),!0),u("problemsErrorIcon.foreground",D,c.kg("problemsErrorIconForeground","The color used for the problems error icon.")),u("problemsWarningIcon.foreground",F,c.kg("problemsWarningIconForeground","The color used for the problems warning icon.")),u("problemsInfoIcon.foreground",V,c.kg("problemsInfoIconForeground","The color used for the problems info icon.")),u("minimap.findMatchHighlight",{light:"#d18616",dark:"#d18616",hcDark:"#AB5A00",hcLight:"#0F4A85"},c.kg("minimapFindMatchHighlight","Minimap marker color for find matches."),!0)),oe=(u("minimap.selectionOccurrenceHighlight",{light:"#c9c9c9",dark:"#676767",hcDark:"#ffffff",hcLight:"#0F4A85"},c.kg("minimapSelectionOccurrenceHighlight","Minimap marker color for repeating editor selections."),!0),u("minimap.selectionHighlight",{light:"#ADD6FF",dark:"#264F78",hcDark:"#ffffff",hcLight:"#0F4A85"},c.kg("minimapSelectionHighlight","Minimap marker color for the editor selection."),!0),u("minimap.infoHighlight",{dark:V,light:V,hcDark:z,hcLight:z},c.kg("minimapInfo","Minimap marker color for infos."))),ae=u("minimap.warningHighlight",{dark:F,light:F,hcDark:P,hcLight:P},c.kg("overviewRuleWarning","Minimap marker color for warnings.")),le=u("minimap.errorHighlight",{dark:new s.Q1(new s.bU(255,18,18,.7)),light:new s.Q1(new s.bU(255,18,18,.7)),hcDark:new s.Q1(new s.bU(255,50,50,1)),hcLight:"#B5200D"},c.kg("minimapError","Minimap marker color for errors.")),ce=(u("minimap.background",null,c.kg("minimapBackground","Minimap background color.")),u("minimap.foregroundOpacity",s.Q1.fromHex("#000f"),c.kg("minimapForegroundOpacity",'Opacity of foreground elements rendered in the minimap. For example, "#000000c0" will render the elements with 75% opacity.')),u("minimapSlider.background",f(N,.5),c.kg("minimapSliderBackground","Minimap slider background color.")),u("minimapSlider.hoverBackground",f(T,.5),c.kg("minimapSliderHoverBackground","Minimap slider background color when hovering.")),u("minimapSlider.activeBackground",f(A,.5),c.kg("minimapSliderActiveBackground","Minimap slider background color when clicked on.")),u("charts.foreground",C,c.kg("chartsForeground","The foreground color used in charts.")),u("charts.lines",f(C,.5),c.kg("chartsLines","The color used for horizontal lines in charts.")),u("charts.red",D,c.kg("chartsRed","The red color used in chart visualizations.")),u("charts.blue",V,c.kg("chartsBlue","The blue color used in chart visualizations.")),u("charts.yellow",F,c.kg("chartsYellow","The yellow color used in chart visualizations.")),u("charts.orange",se,c.kg("chartsOrange","The orange color used in chart visualizations.")),u("charts.green",{dark:"#89D185",light:"#388A34",hcDark:"#89D185",hcLight:"#374e06"},c.kg("chartsGreen","The green color used in chart visualizations.")),u("charts.purple",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},c.kg("chartsPurple","The purple color used in chart visualizations.")),u("input.background",{dark:"#3C3C3C",light:s.Q1.white,hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputBoxBackground","Input box background.")),u("input.foreground",C,c.kg("inputBoxForeground","Input box foreground.")),u("input.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("inputBoxBorder","Input box border.")),u("inputOption.activeBorder",{dark:"#007ACC",light:"#007ACC",hcDark:w,hcLight:w},c.kg("inputBoxActiveOptionBorder","Border color of activated options in input fields."))),he=u("inputOption.hoverBackground",{dark:"#5a5d5e80",light:"#b8b8b850",hcDark:null,hcLight:null},c.kg("inputOption.hoverBackground","Background color of activated options in input fields.")),ue=u("inputOption.activeBackground",{dark:f(L,.4),light:f(L,.2),hcDark:s.Q1.transparent,hcLight:s.Q1.transparent},c.kg("inputOption.activeBackground","Background hover color of options in input fields.")),de=u("inputOption.activeForeground",{dark:s.Q1.white,light:s.Q1.black,hcDark:C,hcLight:C},c.kg("inputOption.activeForeground","Foreground color of activated options in input fields.")),ge=(u("input.placeholderForeground",{light:f(C,.5),dark:f(C,.5),hcDark:f(C,.7),hcLight:f(C,.7)},c.kg("inputPlaceholderForeground","Input box foreground color for placeholder text.")),u("inputValidation.infoBackground",{dark:"#063B49",light:"#D6ECF2",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputValidationInfoBackground","Input validation background color for information severity.")),u("inputValidation.infoForeground",{dark:null,light:null,hcDark:null,hcLight:C},c.kg("inputValidationInfoForeground","Input validation foreground color for information severity.")),u("inputValidation.infoBorder",{dark:"#007acc",light:"#007acc",hcDark:w,hcLight:w},c.kg("inputValidationInfoBorder","Input validation border color for information severity.")),u("inputValidation.warningBackground",{dark:"#352A05",light:"#F6F5D2",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputValidationWarningBackground","Input validation background color for warning severity.")),u("inputValidation.warningForeground",{dark:null,light:null,hcDark:null,hcLight:C},c.kg("inputValidationWarningForeground","Input validation foreground color for warning severity.")),u("inputValidation.warningBorder",{dark:"#B89500",light:"#B89500",hcDark:w,hcLight:w},c.kg("inputValidationWarningBorder","Input validation border color for warning severity.")),u("inputValidation.errorBackground",{dark:"#5A1D1D",light:"#F2DEDE",hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("inputValidationErrorBackground","Input validation background color for error severity.")),u("inputValidation.errorForeground",{dark:null,light:null,hcDark:null,hcLight:C},c.kg("inputValidationErrorForeground","Input validation foreground color for error severity.")),u("inputValidation.errorBorder",{dark:"#BE1100",light:"#BE1100",hcDark:w,hcLight:w},c.kg("inputValidationErrorBorder","Input validation border color for error severity.")),u("dropdown.background",{dark:"#3C3C3C",light:s.Q1.white,hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("dropdownBackground","Dropdown background."))),fe=(u("dropdown.listBackground",{dark:null,light:null,hcDark:s.Q1.black,hcLight:s.Q1.white},c.kg("dropdownListBackground","Dropdown list background.")),u("dropdown.foreground",{dark:"#F0F0F0",light:C,hcDark:s.Q1.white,hcLight:C},c.kg("dropdownForeground","Dropdown foreground."))),me=u("dropdown.border",{dark:ge,light:"#CECECE",hcDark:w,hcLight:w},c.kg("dropdownBorder","Dropdown border.")),pe=u("button.foreground",s.Q1.white,c.kg("buttonForeground","Button foreground color.")),be=(u("button.separator",f(pe,.4),c.kg("buttonSeparator","Button separator color.")),u("button.background",{dark:"#0E639C",light:"#007ACC",hcDark:null,hcLight:"#0F4A85"},c.kg("buttonBackground","Button background color."))),_e=(u("button.hoverBackground",{dark:g(be,.2),light:d(be,.2),hcDark:be,hcLight:be},c.kg("buttonHoverBackground","Button background color when hovering.")),u("button.border",w,c.kg("buttonBorder","Button border color.")),u("button.secondaryForeground",{dark:s.Q1.white,light:s.Q1.white,hcDark:s.Q1.white,hcLight:C},c.kg("buttonSecondaryForeground","Secondary button foreground color.")),u("button.secondaryBackground",{dark:"#3A3D41",light:"#5F6A79",hcDark:null,hcLight:s.Q1.white},c.kg("buttonSecondaryBackground","Secondary button background color."))),ke=(u("button.secondaryHoverBackground",{dark:g(_e,.2),light:d(_e,.2),hcDark:null,hcLight:null},c.kg("buttonSecondaryHoverBackground","Secondary button background color when hovering.")),u("radio.activeForeground",de,c.kg("radioActiveForeground","Foreground color of active radio option."))),ve=(u("radio.activeBackground",ue,c.kg("radioBackground","Background color of active radio option.")),u("radio.activeBorder",ce,c.kg("radioActiveBorder","Border color of the active radio option.")),u("radio.inactiveForeground",null,c.kg("radioInactiveForeground","Foreground color of inactive radio option.")),u("radio.inactiveBackground",null,c.kg("radioInactiveBackground","Background color of inactive radio option.")),u("radio.inactiveBorder",{light:f(ke,.2),dark:f(ke,.2),hcDark:f(ke,.4),hcLight:f(ke,.2)},c.kg("radioInactiveBorder","Border color of the inactive radio option.")),u("radio.inactiveHoverBackground",he,c.kg("radioHoverBackground","Background color of inactive active radio option when hovering.")),u("checkbox.background",ge,c.kg("checkbox.background","Background color of checkbox widget.")),u("checkbox.selectBackground",O,c.kg("checkbox.select.background","Background color of checkbox widget when the element it's in is selected.")),u("checkbox.foreground",fe,c.kg("checkbox.foreground","Foreground color of checkbox widget.")),u("checkbox.border",me,c.kg("checkbox.border","Border color of checkbox widget.")),u("checkbox.selectBorder",y,c.kg("checkbox.select.border","Border color of checkbox widget when the element it's in is selected.")),u("keybindingLabel.background",{dark:new s.Q1(new s.bU(128,128,128,.17)),light:new s.Q1(new s.bU(221,221,221,.4)),hcDark:s.Q1.transparent,hcLight:s.Q1.transparent},c.kg("keybindingLabelBackground","Keybinding label background color. The keybinding label is used to represent a keyboard shortcut.")),u("keybindingLabel.foreground",{dark:s.Q1.fromHex("#CCCCCC"),light:s.Q1.fromHex("#555555"),hcDark:s.Q1.white,hcLight:C},c.kg("keybindingLabelForeground","Keybinding label foreground color. The keybinding label is used to represent a keyboard shortcut.")),u("keybindingLabel.border",{dark:new s.Q1(new s.bU(51,51,51,.6)),light:new s.Q1(new s.bU(204,204,204,.4)),hcDark:new s.Q1(new s.bU(111,195,223)),hcLight:w},c.kg("keybindingLabelBorder","Keybinding label border color. The keybinding label is used to represent a keyboard shortcut.")),u("keybindingLabel.bottomBorder",{dark:new s.Q1(new s.bU(68,68,68,.6)),light:new s.Q1(new s.bU(187,187,187,.4)),hcDark:new s.Q1(new s.bU(111,195,223)),hcLight:C},c.kg("keybindingLabelBottomBorder","Keybinding label border bottom color. The keybinding label is used to represent a keyboard shortcut.")),u("list.focusBackground",null,c.kg("listFocusBackground","List/Tree background color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),u("list.focusForeground",null,c.kg("listFocusForeground","List/Tree foreground color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),u("list.focusOutline",{dark:L,light:L,hcDark:S,hcLight:S},c.kg("listFocusOutline","List/Tree outline color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),u("list.focusAndSelectionOutline",null,c.kg("listFocusAndSelectionOutline","List/Tree outline color for the focused item when the list/tree is active and selected. An active list/tree has keyboard focus, an inactive does not.")),u("list.activeSelectionBackground",{dark:"#04395E",light:"#0060C0",hcDark:null,hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("listActiveSelectionBackground","List/Tree background color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not."))),Ce=u("list.activeSelectionForeground",{dark:s.Q1.white,light:s.Q1.white,hcDark:null,hcLight:null},c.kg("listActiveSelectionForeground","List/Tree foreground color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),ye=u("list.activeSelectionIconForeground",null,c.kg("listActiveSelectionIconForeground","List/Tree icon foreground color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),Le=(u("list.inactiveSelectionBackground",{dark:"#37373D",light:"#E4E6F1",hcDark:null,hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("listInactiveSelectionBackground","List/Tree background color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveSelectionForeground",null,c.kg("listInactiveSelectionForeground","List/Tree foreground color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveSelectionIconForeground",null,c.kg("listInactiveSelectionIconForeground","List/Tree icon foreground color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveFocusBackground",null,c.kg("listInactiveFocusBackground","List/Tree background color for the focused item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.inactiveFocusOutline",null,c.kg("listInactiveFocusOutline","List/Tree outline color for the focused item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),u("list.hoverBackground",{dark:"#2A2D2E",light:"#F0F0F0",hcDark:s.Q1.white.transparent(.1),hcLight:s.Q1.fromHex("#0F4A85").transparent(.1)},c.kg("listHoverBackground","List/Tree background when hovering over items using the mouse.")),u("list.hoverForeground",null,c.kg("listHoverForeground","List/Tree foreground when hovering over items using the mouse.")),u("list.dropBackground",{dark:"#062F4A",light:"#D6EBFF",hcDark:null,hcLight:null},c.kg("listDropBackground","List/Tree drag and drop background when moving items over other items when using the mouse.")),u("list.dropBetweenBackground",{dark:y,light:y,hcDark:null,hcLight:null},c.kg("listDropBetweenBackground","List/Tree drag and drop border color when moving items between items when using the mouse.")),u("list.highlightForeground",{dark:"#2AAAFF",light:"#0066BF",hcDark:L,hcLight:L},c.kg("highlight","List/Tree foreground color of the match highlights when searching inside the list/tree.")));u("list.focusHighlightForeground",{dark:Le,light:(we=ve,Se=Le,xe="#BBE7FF",{op:6,if:we,then:Se,else:xe}),hcDark:Le,hcLight:Le},c.kg("listFocusHighlightForeground","List/Tree foreground color of the match highlights on actively focused items when searching inside the list/tree."));var we,Se,xe;u("list.invalidItemForeground",{dark:"#B89500",light:"#B89500",hcDark:"#B89500",hcLight:"#B5200D"},c.kg("invalidItemForeground","List/Tree foreground color for invalid items, for example an unresolved root in explorer.")),u("list.errorForeground",{dark:"#F88070",light:"#B01011",hcDark:null,hcLight:null},c.kg("listErrorForeground","Foreground color of list items containing errors.")),u("list.warningForeground",{dark:"#CCA700",light:"#855F00",hcDark:null,hcLight:null},c.kg("listWarningForeground","Foreground color of list items containing warnings.")),u("listFilterWidget.background",{light:d(O,0),dark:g(O,0),hcDark:O,hcLight:O},c.kg("listFilterWidgetBackground","Background color of the type filter widget in lists and trees.")),u("listFilterWidget.outline",{dark:s.Q1.transparent,light:s.Q1.transparent,hcDark:"#f38518",hcLight:"#007ACC"},c.kg("listFilterWidgetOutline","Outline color of the type filter widget in lists and trees.")),u("listFilterWidget.noMatchesOutline",{dark:"#BE1100",light:"#BE1100",hcDark:w,hcLight:w},c.kg("listFilterWidgetNoMatchesOutline","Outline color of the type filter widget in lists and trees, when there are no matches.")),u("listFilterWidget.shadow",J,c.kg("listFilterWidgetShadow","Shadow color of the type filter widget in lists and trees.")),u("list.filterMatchBackground",{dark:q,light:q,hcDark:null,hcLight:null},c.kg("listFilterMatchHighlight","Background color of the filtered match.")),u("list.filterMatchBorder",{dark:W,light:W,hcDark:w,hcLight:S},c.kg("listFilterMatchHighlightBorder","Border color of the filtered match.")),u("list.deemphasizedForeground",{dark:"#8C8C8C",light:"#8E8E90",hcDark:"#A7A8A9",hcLight:"#666666"},c.kg("listDeemphasizedForeground","List/Tree foreground color for items that are deemphasized."));const Ee=u("tree.indentGuidesStroke",{dark:"#585858",light:"#a9a9a9",hcDark:"#a9a9a9",hcLight:"#a5a5a5"},c.kg("treeIndentGuidesStroke","Tree stroke color for the indentation guides.")),Ne=(u("tree.inactiveIndentGuidesStroke",f(Ee,.4),c.kg("treeInactiveIndentGuidesStroke","Tree stroke color for the indentation guides that are not active.")),u("tree.tableColumnsBorder",{dark:"#CCCCCC20",light:"#61616120",hcDark:null,hcLight:null},c.kg("tableColumnsBorder","Table border color between columns.")),u("tree.tableOddRowsBackground",{dark:f(C,.04),light:f(C,.04),hcDark:null,hcLight:null},c.kg("tableOddRowsBackgroundColor","Background color for odd table rows.")),u("editorActionList.background",O,c.kg("editorActionListBackground","Action List background color.")),u("editorActionList.foreground",M,c.kg("editorActionListForeground","Action List foreground color.")),u("editorActionList.focusForeground",Ce,c.kg("editorActionListFocusForeground","Action List foreground color for the focused item.")),u("editorActionList.focusBackground",ve,c.kg("editorActionListFocusBackground","Action List background color for the focused item.")),u("menu.border",{dark:null,light:null,hcDark:w,hcLight:w},c.kg("menuBorder","Border color of menus.")),u("menu.foreground",fe,c.kg("menuForeground","Foreground color of menu items.")),u("menu.background",ge,c.kg("menuBackground","Background color of menu items.")),u("menu.selectionForeground",Ce,c.kg("menuSelectionForeground","Foreground color of the selected menu item in menus.")),u("menu.selectionBackground",ve,c.kg("menuSelectionBackground","Background color of the selected menu item in menus.")),u("menu.selectionBorder",{dark:null,light:null,hcDark:S,hcLight:S},c.kg("menuSelectionBorder","Border color of the selected menu item in menus.")),u("menu.separatorBackground",{dark:"#606060",light:"#D4D4D4",hcDark:w,hcLight:w},c.kg("menuSeparatorBackground","Color of a separator menu item in menus.")),u("quickInput.background",O,c.kg("pickerBackground","Quick picker background color. The quick picker widget is the container for pickers like the command palette.")),u("quickInput.foreground",M,c.kg("pickerForeground","Quick picker foreground color. The quick picker widget is the container for pickers like the command palette.")),u("quickInputTitle.background",{dark:new s.Q1(new s.bU(255,255,255,.105)),light:new s.Q1(new s.bU(0,0,0,.06)),hcDark:"#000000",hcLight:s.Q1.white},c.kg("pickerTitleBackground","Quick picker title background color. The quick picker widget is the container for pickers like the command palette.")),u("pickerGroup.foreground",{dark:"#3794FF",light:"#0066BF",hcDark:s.Q1.white,hcLight:"#0F4A85"},c.kg("pickerGroupForeground","Quick picker color for grouping labels.")),u("pickerGroup.border",{dark:"#3F3F46",light:"#CCCEDB",hcDark:s.Q1.white,hcLight:"#0F4A85"},c.kg("pickerGroupBorder","Quick picker color for grouping borders.")),u("quickInput.list.focusBackground",null,"",void 0,c.kg("quickInput.list.focusBackground deprecation","Please use quickInputList.focusBackground instead")));u("quickInputList.focusForeground",Ce,c.kg("quickInput.listFocusForeground","Quick picker foreground color for the focused item.")),u("quickInputList.focusIconForeground",ye,c.kg("quickInput.listFocusIconForeground","Quick picker icon foreground color for the focused item.")),u("quickInputList.focusBackground",{dark:m(Ne,ve),light:m(Ne,ve),hcDark:null,hcLight:null},c.kg("quickInput.listFocusBackground","Quick picker background color for the focused item.")),u("search.resultsInfoForeground",{light:C,dark:f(C,.65),hcDark:C,hcLight:C},c.kg("search.resultsInfoForeground","Color of the text in the search viewlet's completion message.")),u("searchEditor.findMatchBackground",{light:f(q,.66),dark:f(q,.66),hcDark:q,hcLight:q},c.kg("searchEditor.queryMatch","Color of the Search Editor query matches.")),u("searchEditor.findMatchBorder",{light:f(W,.66),dark:f(W,.66),hcDark:W,hcLight:W},c.kg("searchEditor.editorFindMatchBorder","Border color of the Search Editor query matches."))},5890:(e,t,n)=>{var r={"./simpleWorker":1929,"./simpleWorker.js":1929,"monaco-editor/esm/vs/base/common/worker/simpleWorker":1929,"monaco-editor/esm/vs/base/common/worker/simpleWorker.js":1929};function i(e){return Promise.resolve().then((()=>{if(!n.o(r,e)){var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}return n(r[e])}))}i.keys=()=>Object.keys(r),i.id=5890,e.exports=i},5982:(e,t,n)=>{"use strict";n.d(t,{x:()=>r});class r{static getLanguageId(e){return(255&e)>>>0}static getTokenType(e){return(768&e)>>>8}static containsBalancedBrackets(e){return 0!==(1024&e)}static getFontStyle(e){return(30720&e)>>>11}static getForeground(e){return(16744448&e)>>>15}static getBackground(e){return(4278190080&e)>>>24}static getClassNameFromMetadata(e){let t="mtk"+this.getForeground(e);const n=this.getFontStyle(e);return 1&n&&(t+=" mtki"),2&n&&(t+=" mtkb"),4&n&&(t+=" mtku"),8&n&&(t+=" mtks"),t}static getInlineStyleFromMetadata(e,t){const n=this.getForeground(e),r=this.getFontStyle(e);let i=`color: ${t[n]};`;1&r&&(i+="font-style: italic;"),2&r&&(i+="font-weight: bold;");let s="";return 4&r&&(s+=" underline"),8&r&&(s+=" line-through"),s&&(i+=`text-decoration:${s};`),i}static getPresentationFromMetadata(e){const t=this.getForeground(e),n=this.getFontStyle(e);return{foreground:t,italic:Boolean(1&n),bold:Boolean(2&n),underline:Boolean(4&n),strikethrough:Boolean(8&n)}}}},6041:(e,t,n)=>{"use strict";function r(e,t){const n=function(e,t,n=e.length-1){for(let r=n;r>=0;r--){if(t(e[r]))return r}return-1}(e,t);if(-1!==n)return e[n]}function i(e,t){const n=s(e,t);return-1===n?void 0:e[n]}function s(e,t,n=0,r=e.length){let i=n,s=r;for(;ir,XP:()=>o,hw:()=>a,iM:()=>s,lx:()=>i,vJ:()=>l});class l{static{this.assertInvariants=!1}constructor(e){this._array=e,this._findLastMonotonousLastIdx=0}findLastMonotonous(e){if(l.assertInvariants){if(this._prevFindLastPredicate)for(const t of this._array)if(this._prevFindLastPredicate(t)&&!e(t))throw new Error("MonotonousArray: current predicate must be weaker than (or equal to) the previous predicate.");this._prevFindLastPredicate=e}const t=s(this._array,e,this._findLastMonotonousLastIdx);return this._findLastMonotonousLastIdx=t+1,-1===t?void 0:this._array[t]}}},6223:(e,t,n)=>{"use strict";n.d(t,{A5:()=>r,Dg:()=>l,F4:()=>d,L5:()=>u,Wo:()=>h,X2:()=>a,ZS:()=>i,nk:()=>c,vd:()=>g});var r,i,s,o=n(146);!function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=4]="Right",e[e.Full=7]="Full"}(r||(r={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=3]="Right"}(i||(i={})),function(e){e[e.Both=0]="Both",e[e.Right=1]="Right",e[e.Left=2]="Left",e[e.None=3]="None"}(s||(s={}));class a{get originalIndentSize(){return this._indentSizeIsTabSize?"tabSize":this.indentSize}constructor(e){this._textModelResolvedOptionsBrand=void 0,this.tabSize=Math.max(1,0|e.tabSize),"tabSize"===e.indentSize?(this.indentSize=this.tabSize,this._indentSizeIsTabSize=!0):(this.indentSize=Math.max(1,0|e.indentSize),this._indentSizeIsTabSize=!1),this.insertSpaces=Boolean(e.insertSpaces),this.defaultEOL=0|e.defaultEOL,this.trimAutoWhitespace=Boolean(e.trimAutoWhitespace),this.bracketPairColorizationOptions=e.bracketPairColorizationOptions}equals(e){return this.tabSize===e.tabSize&&this._indentSizeIsTabSize===e._indentSizeIsTabSize&&this.indentSize===e.indentSize&&this.insertSpaces===e.insertSpaces&&this.defaultEOL===e.defaultEOL&&this.trimAutoWhitespace===e.trimAutoWhitespace&&(0,o.aI)(this.bracketPairColorizationOptions,e.bracketPairColorizationOptions)}createChangeEvent(e){return{tabSize:this.tabSize!==e.tabSize,indentSize:this.indentSize!==e.indentSize,insertSpaces:this.insertSpaces!==e.insertSpaces,trimAutoWhitespace:this.trimAutoWhitespace!==e.trimAutoWhitespace}}}class l{constructor(e,t){this._findMatchBrand=void 0,this.range=e,this.matches=t}}function c(e){return e&&"function"===typeof e.read}class h{constructor(e,t,n,r,i,s){this.identifier=e,this.range=t,this.text=n,this.forceMoveMarkers=r,this.isAutoWhitespaceEdit=i,this._isTracked=s}}class u{constructor(e,t,n){this.regex=e,this.wordSeparators=t,this.simpleSearch=n}}class d{constructor(e,t,n){this.reverseEdits=e,this.changes=t,this.trimAutoWhitespaceLineNumbers=n}}function g(e){return!e.isTooLargeForSyncing()&&!e.isForSimpleWidget}},6359:(e,t,n)=>{"use strict";n.d(t,{O:()=>s});var r=n(6782),i=n(631);const s=new class{constructor(){this.data=new Map}add(e,t){r.ok(i.Kg(e)),r.ok(i.Gv(t)),r.ok(!this.data.has(e),"There is already an extension with this id"),this.data.set(e,t)}as(e){return this.data.get(e)||null}}},6456:(e,t,n)=>{"use strict";n.d(t,{ny:()=>r,v$:()=>c,zl:()=>d});var r,i=n(4383),s=n(8067),o=n(1508),a=n(9400),l=n(8821);function c(e,t){return a.r.isUri(e)?(0,o.Q_)(e.scheme,t):(0,o.ns)(e,t+":")}!function(e){e.inMemory="inmemory",e.vscode="vscode",e.internal="private",e.walkThrough="walkThrough",e.walkThroughSnippet="walkThroughSnippet",e.http="http",e.https="https",e.file="file",e.mailto="mailto",e.untitled="untitled",e.data="data",e.command="command",e.vscodeRemote="vscode-remote",e.vscodeRemoteResource="vscode-remote-resource",e.vscodeManagedRemoteResource="vscode-managed-remote-resource",e.vscodeUserData="vscode-userdata",e.vscodeCustomEditor="vscode-custom-editor",e.vscodeNotebookCell="vscode-notebook-cell",e.vscodeNotebookCellMetadata="vscode-notebook-cell-metadata",e.vscodeNotebookCellMetadataDiff="vscode-notebook-cell-metadata-diff",e.vscodeNotebookCellOutput="vscode-notebook-cell-output",e.vscodeNotebookCellOutputDiff="vscode-notebook-cell-output-diff",e.vscodeNotebookMetadata="vscode-notebook-metadata",e.vscodeInteractiveInput="vscode-interactive-input",e.vscodeSettings="vscode-settings",e.vscodeWorkspaceTrust="vscode-workspace-trust",e.vscodeTerminal="vscode-terminal",e.vscodeChatCodeBlock="vscode-chat-code-block",e.vscodeChatCodeCompareBlock="vscode-chat-code-compare-block",e.vscodeChatSesssion="vscode-chat-editor",e.webviewPanel="webview-panel",e.vscodeWebview="vscode-webview",e.extension="extension",e.vscodeFileResource="vscode-file",e.tmp="tmp",e.vsls="vsls",e.vscodeSourceControl="vscode-scm",e.commentsInput="comment",e.codeSetting="code-setting",e.outputChannel="output"}(r||(r={}));const h=new class{constructor(){this._hosts=Object.create(null),this._ports=Object.create(null),this._connectionTokens=Object.create(null),this._preferredWebSchema="http",this._delegate=null,this._serverRootPath="/"}setPreferredWebSchema(e){this._preferredWebSchema=e}get _remoteResourcesPath(){return l.SA.join(this._serverRootPath,r.vscodeRemoteResource)}rewrite(e){if(this._delegate)try{return this._delegate(e)}catch(h){return i.dz(h),e}const t=e.authority;let n=this._hosts[t];n&&-1!==n.indexOf(":")&&-1===n.indexOf("[")&&(n=`[${n}]`);const o=this._ports[t],l=this._connectionTokens[t];let c=`path=${encodeURIComponent(e.path)}`;return"string"===typeof l&&(c+=`&tkn=${encodeURIComponent(l)}`),a.r.from({scheme:s.HZ?this._preferredWebSchema:r.vscodeRemoteResource,authority:`${n}:${o}`,path:this._remoteResourcesPath,query:c})}};class u{static{this.FALLBACK_AUTHORITY="vscode-app"}asBrowserUri(e){const t=this.toUri(e);return this.uriToBrowserUri(t)}uriToBrowserUri(e){return e.scheme===r.vscodeRemote?h.rewrite(e):e.scheme!==r.file||!s.ib&&s.lg!==`${r.vscodeFileResource}://${u.FALLBACK_AUTHORITY}`?e:e.with({scheme:r.vscodeFileResource,authority:e.authority||u.FALLBACK_AUTHORITY,query:null,fragment:null})}toUri(e,t){if(a.r.isUri(e))return e;if(globalThis._VSCODE_FILE_ROOT){const t=globalThis._VSCODE_FILE_ROOT;if(/^\w[\w\d+.-]*:\/\//.test(t))return a.r.joinPath(a.r.parse(t,!0),e);const n=l.fj(t,e);return a.r.file(n)}return a.r.parse(t.toUrl(e))}}const d=new u;var g;!function(e){const t=new Map([["1",{"Cross-Origin-Opener-Policy":"same-origin"}],["2",{"Cross-Origin-Embedder-Policy":"require-corp"}],["3",{"Cross-Origin-Opener-Policy":"same-origin","Cross-Origin-Embedder-Policy":"require-corp"}]]);e.CoopAndCoep=Object.freeze(t.get("3"));const n="vscode-coi";e.getHeadersFromQuery=function(e){let r;"string"===typeof e?r=new URL(e).searchParams:e instanceof URL?r=e.searchParams:a.r.isUri(e)&&(r=new URL(e.toString(!0)).searchParams);const i=r?.get(n);if(i)return t.get(i)},e.addSearchParam=function(e,t,r){if(!globalThis.crossOriginIsolated)return;const i=t&&r?"3":r?"2":"1";e instanceof URLSearchParams?e.set(n,i):e[n]=i}}(g||(g={}))},6486:(e,t,n)=>{"use strict";n.d(t,{Io:()=>o,Ld:()=>s,Th:()=>l});var r=n(2522),i=n(8925);const s=function(e=""){let t="(-?\\d*\\.\\d\\w*)|([^";for(const n of"`~!@#$%^&*()-=+[{]}\\|;:'\",.<>/?")e.indexOf(n)>=0||(t+="\\"+n);return t+="\\s]+)",new RegExp(t,"g")}();function o(e){let t=s;if(e&&e instanceof RegExp)if(e.global)t=e;else{let n="g";e.ignoreCase&&(n+="i"),e.multiline&&(n+="m"),e.unicode&&(n+="u"),t=new RegExp(e.source,n)}return t.lastIndex=0,t}const a=new i.w;function l(e,t,n,i,s){if(t=o(t),s||(s=r.f.first(a)),n.length>s.maxLen){let r=e-s.maxLen/2;return r<0?r=0:i+=r,l(e,t,n=n.substring(r,e+s.maxLen/2),i,s)}const h=Date.now(),u=e-1-i;let d=-1,g=null;for(let r=1;!(Date.now()-h>=s.timeBudget);r++){const e=u-s.windowSize*r;t.lastIndex=Math.max(0,e);const i=c(t,n,u,d);if(!i&&g)break;if(g=i,e<=0)break;d=e}if(g){const e={word:g[0],startColumn:i+1+g.index,endColumn:i+1+g.index+g[0].length};return t.lastIndex=0,e}return null}function c(e,t,n,r){let i;for(;i=e.exec(t);){const t=i.index||0;if(t<=n&&e.lastIndex>=n)return i;if(r>0&&t>r)return null}return null}a.unshift({maxLen:1e3,windowSize:15,timeBudget:150})},6571:(e,t,n)=>{"use strict";n.d(t,{M:()=>a,S:()=>l});var r=n(4383),i=n(4444),s=n(6677),o=n(6041);class a{static fromRangeInclusive(e){return new a(e.startLineNumber,e.endLineNumber+1)}static joinMany(e){if(0===e.length)return[];let t=new l(e[0].slice());for(let n=1;nt)throw new r.D7(`startLineNumber ${e} cannot be after endLineNumberExclusive ${t}`);this.startLineNumber=e,this.endLineNumberExclusive=t}contains(e){return this.startLineNumber<=e&&et.endLineNumberExclusive>=e.startLineNumber)),n=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===n)this._normalizedRanges.splice(t,0,e);else if(t===n-1){const n=this._normalizedRanges[t];this._normalizedRanges[t]=n.join(e)}else{const r=this._normalizedRanges[t].join(this._normalizedRanges[n-1]).join(e);this._normalizedRanges.splice(t,n-t,r)}}contains(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumber<=e));return!!t&&t.endLineNumberExclusive>e}intersects(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumbere.startLineNumber}getUnion(e){if(0===this._normalizedRanges.length)return e;if(0===e._normalizedRanges.length)return this;const t=[];let n=0,r=0,i=null;for(;n=s.startLineNumber?i=new a(i.startLineNumber,Math.max(i.endLineNumberExclusive,s.endLineNumberExclusive)):(t.push(i),i=s)}return null!==i&&t.push(i),new l(t)}subtractFrom(e){const t=(0,o.hw)(this._normalizedRanges,(t=>t.endLineNumberExclusive>=e.startLineNumber)),n=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===n)return new l([e]);const r=[];let i=e.startLineNumber;for(let s=t;si&&r.push(new a(i,e.startLineNumber)),i=e.endLineNumberExclusive}return ie.toString())).join(", ")}getIntersection(e){const t=[];let n=0,r=0;for(;nt.delta(e))))}}},6677:(e,t,n)=>{"use strict";n.d(t,{Q:()=>i});var r=n(3069);class i{constructor(e,t,n,r){e>n||e===n&&t>r?(this.startLineNumber=n,this.startColumn=r,this.endLineNumber=e,this.endColumn=t):(this.startLineNumber=e,this.startColumn=t,this.endLineNumber=n,this.endColumn=r)}isEmpty(){return i.isEmpty(this)}static isEmpty(e){return e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn}containsPosition(e){return i.containsPosition(this,e)}static containsPosition(e,t){return!(t.lineNumbere.endLineNumber)&&(!(t.lineNumber===e.startLineNumber&&t.columne.endColumn))}static strictContainsPosition(e,t){return!(t.lineNumbere.endLineNumber)&&(!(t.lineNumber===e.startLineNumber&&t.column<=e.startColumn)&&!(t.lineNumber===e.endLineNumber&&t.column>=e.endColumn))}containsRange(e){return i.containsRange(this,e)}static containsRange(e,t){return!(t.startLineNumbere.endLineNumber||t.endLineNumber>e.endLineNumber)&&(!(t.startLineNumber===e.startLineNumber&&t.startColumne.endColumn)))}strictContainsRange(e){return i.strictContainsRange(this,e)}static strictContainsRange(e,t){return!(t.startLineNumbere.endLineNumber||t.endLineNumber>e.endLineNumber)&&(!(t.startLineNumber===e.startLineNumber&&t.startColumn<=e.startColumn)&&!(t.endLineNumber===e.endLineNumber&&t.endColumn>=e.endColumn)))}plusRange(e){return i.plusRange(this,e)}static plusRange(e,t){let n,r,s,o;return t.startLineNumbere.endLineNumber?(s=t.endLineNumber,o=t.endColumn):t.endLineNumber===e.endLineNumber?(s=t.endLineNumber,o=Math.max(t.endColumn,e.endColumn)):(s=e.endLineNumber,o=e.endColumn),new i(n,r,s,o)}intersectRanges(e){return i.intersectRanges(this,e)}static intersectRanges(e,t){let n=e.startLineNumber,r=e.startColumn,s=e.endLineNumber,o=e.endColumn;const a=t.startLineNumber,l=t.startColumn,c=t.endLineNumber,h=t.endColumn;return nc?(s=c,o=h):s===c&&(o=Math.min(o,h)),n>s||n===s&&r>o?null:new i(n,r,s,o)}equalsRange(e){return i.equalsRange(this,e)}static equalsRange(e,t){return!e&&!t||!!e&&!!t&&e.startLineNumber===t.startLineNumber&&e.startColumn===t.startColumn&&e.endLineNumber===t.endLineNumber&&e.endColumn===t.endColumn}getEndPosition(){return i.getEndPosition(this)}static getEndPosition(e){return new r.y(e.endLineNumber,e.endColumn)}getStartPosition(){return i.getStartPosition(this)}static getStartPosition(e){return new r.y(e.startLineNumber,e.startColumn)}toString(){return"["+this.startLineNumber+","+this.startColumn+" -> "+this.endLineNumber+","+this.endColumn+"]"}setEndPosition(e,t){return new i(this.startLineNumber,this.startColumn,e,t)}setStartPosition(e,t){return new i(e,t,this.endLineNumber,this.endColumn)}collapseToStart(){return i.collapseToStart(this)}static collapseToStart(e){return new i(e.startLineNumber,e.startColumn,e.startLineNumber,e.startColumn)}collapseToEnd(){return i.collapseToEnd(this)}static collapseToEnd(e){return new i(e.endLineNumber,e.endColumn,e.endLineNumber,e.endColumn)}delta(e){return new i(this.startLineNumber+e,this.startColumn,this.endLineNumber+e,this.endColumn)}static fromPositions(e,t=e){return new i(e.lineNumber,e.column,t.lineNumber,t.column)}static lift(e){return e?new i(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):null}static isIRange(e){return e&&"number"===typeof e.startLineNumber&&"number"===typeof e.startColumn&&"number"===typeof e.endLineNumber&&"number"===typeof e.endColumn}static areIntersectingOrTouching(e,t){return!(e.endLineNumbere.startLineNumber}toJSON(){return this}}},6691:(e,t,n)=>{"use strict";n.r(t),n.d(t,{findSectionHeaders:()=>s});const r=new RegExp("\\bMARK:\\s*(.*)$","d"),i=/^-+|-+$/g;function s(e,t){let n=[];if(t.findRegionSectionHeaders&&t.foldingRules?.markers){const r=function(e,t){const n=[],r=e.getLineCount();for(let i=1;i<=r;i++){const r=e.getLineContent(i),s=r.match(t.foldingRules.markers.start);if(s){const e={startLineNumber:i,startColumn:s[0].length+1,endLineNumber:i,endColumn:r.length+1};if(e.endColumn>e.startColumn){const t={range:e,...a(r.substring(s[0].length)),shouldBeInComments:!1};(t.text||t.hasSeparatorLine)&&n.push(t)}}}return n}(e,t);n=n.concat(r)}if(t.findMarkSectionHeaders){const t=function(e){const t=[],n=e.getLineCount();for(let r=1;r<=n;r++){o(e.getLineContent(r),r,t)}return t}(e);n=n.concat(t)}return n}function o(e,t,n){r.lastIndex=0;const i=r.exec(e);if(i){const e={startLineNumber:t,startColumn:i.indices[1][0]+1,endLineNumber:t,endColumn:i.indices[1][1]+1};if(e.endColumn>e.startColumn){const t={range:e,...a(i[1]),shouldBeInComments:!0};(t.text||t.hasSeparatorLine)&&n.push(t)}}}function a(e){const t=(e=e.trim()).startsWith("-");return{text:e=e.replace(i,""),hasSeparatorLine:t}}},6723:(e,t,n)=>{"use strict";n.r(t),n.d(t,{DraggedTreeItemsIdentifier:()=>i,TreeViewsDnDService:()=>r});class r{constructor(){this._dragOperations=new Map}removeDragOperationTransfer(e){if(e&&this._dragOperations.has(e)){const t=this._dragOperations.get(e);return this._dragOperations.delete(e),t}}}class i{constructor(e){this.identifier=e}}},6782:(e,t,n)=>{"use strict";n.d(t,{Ft:()=>o,Xo:()=>a,ok:()=>i,xb:()=>s});var r=n(4383);function i(e,t){if(!e)throw new Error(t?`Assertion failed (${t})`:"Assertion Failed")}function s(e,t="Unreachable"){throw new Error(t)}function o(e){e()||(e(),(0,r.dz)(new r.D7("Assertion Failed")))}function a(e,t){let n=0;for(;n{"use strict";n.r(t),n.d(t,{ILanguageFeaturesService:()=>r});const r=(0,n(3591).u1)("ILanguageFeaturesService")},6958:(e,t,n)=>{"use strict";n.d(t,{YW:()=>A,qg:()=>I});var r=n(1940),i=n(9326),s=n(4320),o=n(8821),a=n(8067),l=n(1508);const c="**",h="/",u="[/\\\\]",d="[^/\\\\]",g=/\//g;function f(e,t){switch(e){case 0:return"";case 1:return`${d}*?`;default:return`(?:${u}|${d}+${u}${t?`|${u}${d}+`:""})*?`}}function m(e,t){if(!e)return[];const n=[];let r=!1,i=!1,s="";for(const o of e){switch(o){case t:if(!r&&!i){n.push(s),s="";continue}break;case"{":r=!0;break;case"}":r=!1;break;case"[":i=!0;break;case"]":i=!1}s+=o}return s&&n.push(s),n}function p(e){if(!e)return"";let t="";const n=m(e,h);if(n.every((e=>e===c)))t=".*";else{let e=!1;n.forEach(((r,i)=>{if(r===c){if(e)return;t+=f(2,i===n.length-1)}else{let e=!1,s="",o=!1,a="";for(const n of r)if("}"!==n&&e)s+=n;else if(!o||"]"===n&&a)switch(n){case"{":e=!0;continue;case"[":o=!0;continue;case"}":{const n=`(?:${m(s,",").map((e=>p(e))).join("|")})`;t+=n,e=!1,s="";break}case"]":t+="["+a+"]",o=!1,a="";break;case"?":t+=d;continue;case"*":t+=f(1);continue;default:t+=(0,l.bm)(n)}else{let e;e="-"===n?n:"^"!==n&&"!"!==n||a?n===h?"":(0,l.bm)(n):"^",a+=e}ix(e,t))).filter((e=>e!==S)),e),r=n.length;if(!r)return S;if(1===r)return n[0];const i=function(t,r){for(let i=0,s=n.length;i!!e.allBasenames));s&&(i.allBasenames=s.allBasenames);const o=n.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);o.length&&(i.allPaths=o);return i}(n,t):(i=C.exec(N(n,t)))?T(i[1].substr(1),n,!0):(i=y.exec(N(n,t)))?T(i[1],n,!1):function(e){try{const t=new RegExp(`^${p(e)}$`);return function(n){return t.lastIndex=0,"string"===typeof n&&t.test(n)?e:null}}catch(t){return S}}(n),L.set(r,s)),E(s,e)}function E(e,t){if("string"===typeof t)return e;const n=function(n,r){return(0,i._1)(n,t.base,!a.j9)?e((0,l.NB)(n.substr(t.base.length),o.Vn),r):null};return n.allBasenames=e.allBasenames,n.allPaths=e.allPaths,n.basenames=e.basenames,n.patterns=e.patterns,n}function N(e,t){return t.trimForExclusions&&e.endsWith("/**")?e.substr(0,e.length-2):e}function T(e,t,n){const r=o.Vn===o.SA.sep,i=r?e:e.replace(g,o.Vn),s=o.Vn+i,a=o.SA.sep+e;let l;return l=n?function(n,o){return"string"!==typeof n||n!==i&&!n.endsWith(s)&&(r||n!==e&&!n.endsWith(a))?null:t}:function(n,s){return"string"!==typeof n||n!==i&&(r||n!==e)?null:t},l.allPaths=[(n?"*/":"./")+e],l}function A(e,t,n){return!(!e||"string"!==typeof t)&&I(e)(t,void 0,n)}function I(e,t={}){if(!e)return w;if("string"===typeof e||function(e){const t=e;if(!t)return!1;return"string"===typeof t.base&&"string"===typeof t.pattern}(e)){const n=x(e,t);if(n===S)return w;const r=function(e,t){return!!n(e,t)};return n.allBasenames&&(r.allBasenames=n.allBasenames),n.allPaths&&(r.allPaths=n.allPaths),r}return function(e,t){const n=O(Object.getOwnPropertyNames(e).map((n=>function(e,t,n){if(!1===t)return S;const i=x(e,n);if(i===S)return S;if("boolean"===typeof t)return i;if(t){const n=t.when;if("string"===typeof n){const t=(t,s,o,a)=>{if(!a||!i(t,s))return null;const l=a(n.replace("$(basename)",(()=>o)));return(0,r.Qg)(l)?l.then((t=>t?e:null)):l?e:null};return t.requiresSiblings=!0,t}}return i}(n,e[n],t))).filter((e=>e!==S))),i=n.length;if(!i)return S;if(!n.some((e=>!!e.requiresSiblings))){if(1===i)return n[0];const e=function(e,t){let i;for(let s=0,o=n.length;s{for(const e of i){const t=await e;if("string"===typeof t)return t}return null})():null},t=n.find((e=>!!e.allBasenames));t&&(e.allBasenames=t.allBasenames);const s=n.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);return s.length&&(e.allPaths=s),e}const s=function(e,t,i){let s,a;for(let l=0,c=n.length;l{for(const e of a){const t=await e;if("string"===typeof t)return t}return null})():null},a=n.find((e=>!!e.allBasenames));a&&(s.allBasenames=a.allBasenames);const l=n.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);l.length&&(s.allPaths=l);return s}(e,t)}function O(e,t){const n=e.filter((e=>!!e.basenames));if(n.length<2)return e;const r=n.reduce(((e,t)=>{const n=t.basenames;return n?e.concat(n):e}),[]);let i;if(t){i=[];for(let e=0,n=r.length;e{const n=t.patterns;return n?e.concat(n):e}),[]);const s=function(e,t){if("string"!==typeof e)return null;if(!t){let n;for(n=e.length;n>0;n--){const t=e.charCodeAt(n-1);if(47===t||92===t)break}t=e.substr(n)}const n=r.indexOf(t);return-1!==n?i[n]:null};s.basenames=r,s.patterns=i,s.allBasenames=r;const o=e.filter((e=>!e.basenames));return o.push(s),o}},7004:(e,t,n)=>{"use strict";n.r(t),n.d(t,{SemanticTokensStylingService:()=>d});var r=n(1484),i=n(154),s=n(5724),o=n(3511),a=n(5538),l=n(4243),c=n(4621),h=function(e,t,n,r){var i,s=arguments.length,o=s<3?t:null===r?r=Object.getOwnPropertyDescriptor(t,n):r;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,n,r);else for(var a=e.length-1;a>=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},u=function(e,t){return function(n,r){t(n,r,e)}};let d=class extends r.jG{constructor(e,t,n){super(),this._themeService=e,this._logService=t,this._languageService=n,this._caches=new WeakMap,this._register(this._themeService.onDidColorThemeChange((()=>{this._caches=new WeakMap})))}getStyling(e){return this._caches.has(e)||this._caches.set(e,new a.SemanticTokensProviderStyling(e.getLegend(),this._themeService,this._languageService,this._logService)),this._caches.get(e)}};d=h([u(0,s.Gy),u(1,o.rr),u(2,i.L)],d),(0,c.v)(l.ISemanticTokensStylingService,d,1)},7119:(e,t,n)=>{"use strict";n.d(t,{AQ:()=>b,aZ:()=>p,l5:()=>C,lQ:()=>k,s7:()=>w,sH:()=>y,sN:()=>_,ss:()=>v,yI:()=>m,zp:()=>L});var r=n(8209),i=n(7661),s=n(5845),o=n(5724);const a=(0,s.x1A)("editor.lineHighlightBackground",null,r.kg("lineHighlight","Background color for the highlight of line at the cursor position.")),l=((0,s.x1A)("editor.lineHighlightBorder",{dark:"#282828",light:"#eeeeee",hcDark:"#f38518",hcLight:s.b1q},r.kg("lineHighlightBorderBox","Background color for the border around the line at the cursor position.")),(0,s.x1A)("editor.rangeHighlightBackground",{dark:"#ffffff0b",light:"#fdff0033",hcDark:null,hcLight:null},r.kg("rangeHighlight","Background color of highlighted ranges, like by quick open and find features. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1A)("editor.rangeHighlightBorder",{dark:null,light:null,hcDark:s.buw,hcLight:s.buw},r.kg("rangeHighlightBorder","Background color of the border around highlighted ranges.")),(0,s.x1A)("editor.symbolHighlightBackground",{dark:s.Ubg,light:s.Ubg,hcDark:null,hcLight:null},r.kg("symbolHighlight","Background color of highlighted symbol, like for go to definition or go next/previous symbol. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1A)("editor.symbolHighlightBorder",{dark:null,light:null,hcDark:s.buw,hcLight:s.buw},r.kg("symbolHighlightBorder","Background color of the border around highlighted symbols.")),(0,s.x1A)("editorCursor.foreground",{dark:"#AEAFAD",light:i.Q1.black,hcDark:i.Q1.white,hcLight:"#0F4A85"},r.kg("caret","Color of the editor cursor."))),c=(0,s.x1A)("editorCursor.background",null,r.kg("editorCursorBackground","The background color of the editor cursor. Allows customizing the color of a character overlapped by a block cursor.")),h=((0,s.x1A)("editorMultiCursor.primary.foreground",l,r.kg("editorMultiCursorPrimaryForeground","Color of the primary editor cursor when multiple cursors are present.")),(0,s.x1A)("editorMultiCursor.primary.background",c,r.kg("editorMultiCursorPrimaryBackground","The background color of the primary editor cursor when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),(0,s.x1A)("editorMultiCursor.secondary.foreground",l,r.kg("editorMultiCursorSecondaryForeground","Color of secondary editor cursors when multiple cursors are present.")),(0,s.x1A)("editorMultiCursor.secondary.background",c,r.kg("editorMultiCursorSecondaryBackground","The background color of secondary editor cursors when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),(0,s.x1A)("editorWhitespace.foreground",{dark:"#e3e4e229",light:"#33333333",hcDark:"#e3e4e229",hcLight:"#CCCCCC"},r.kg("editorWhitespaces","Color of whitespace characters in the editor."))),u=((0,s.x1A)("editorLineNumber.foreground",{dark:"#858585",light:"#237893",hcDark:i.Q1.white,hcLight:"#292929"},r.kg("editorLineNumbers","Color of editor line numbers.")),(0,s.x1A)("editorIndentGuide.background",h,r.kg("editorIndentGuides","Color of the editor indentation guides."),!1,r.kg("deprecatedEditorIndentGuides","'editorIndentGuide.background' is deprecated. Use 'editorIndentGuide.background1' instead."))),d=(0,s.x1A)("editorIndentGuide.activeBackground",h,r.kg("editorActiveIndentGuide","Color of the active editor indentation guides."),!1,r.kg("deprecatedEditorActiveIndentGuide","'editorIndentGuide.activeBackground' is deprecated. Use 'editorIndentGuide.activeBackground1' instead.")),g=((0,s.x1A)("editorIndentGuide.background1",u,r.kg("editorIndentGuides1","Color of the editor indentation guides (1).")),(0,s.x1A)("editorIndentGuide.background2","#00000000",r.kg("editorIndentGuides2","Color of the editor indentation guides (2).")),(0,s.x1A)("editorIndentGuide.background3","#00000000",r.kg("editorIndentGuides3","Color of the editor indentation guides (3).")),(0,s.x1A)("editorIndentGuide.background4","#00000000",r.kg("editorIndentGuides4","Color of the editor indentation guides (4).")),(0,s.x1A)("editorIndentGuide.background5","#00000000",r.kg("editorIndentGuides5","Color of the editor indentation guides (5).")),(0,s.x1A)("editorIndentGuide.background6","#00000000",r.kg("editorIndentGuides6","Color of the editor indentation guides (6).")),(0,s.x1A)("editorIndentGuide.activeBackground1",d,r.kg("editorActiveIndentGuide1","Color of the active editor indentation guides (1).")),(0,s.x1A)("editorIndentGuide.activeBackground2","#00000000",r.kg("editorActiveIndentGuide2","Color of the active editor indentation guides (2).")),(0,s.x1A)("editorIndentGuide.activeBackground3","#00000000",r.kg("editorActiveIndentGuide3","Color of the active editor indentation guides (3).")),(0,s.x1A)("editorIndentGuide.activeBackground4","#00000000",r.kg("editorActiveIndentGuide4","Color of the active editor indentation guides (4).")),(0,s.x1A)("editorIndentGuide.activeBackground5","#00000000",r.kg("editorActiveIndentGuide5","Color of the active editor indentation guides (5).")),(0,s.x1A)("editorIndentGuide.activeBackground6","#00000000",r.kg("editorActiveIndentGuide6","Color of the active editor indentation guides (6).")),(0,s.x1A)("editorActiveLineNumber.foreground",{dark:"#c6c6c6",light:"#0B216F",hcDark:s.buw,hcLight:s.buw},r.kg("editorActiveLineNumber","Color of editor active line number"),!1,r.kg("deprecatedEditorActiveLineNumber","Id is deprecated. Use 'editorLineNumber.activeForeground' instead."))),f=((0,s.x1A)("editorLineNumber.activeForeground",g,r.kg("editorActiveLineNumber","Color of editor active line number")),(0,s.x1A)("editorLineNumber.dimmedForeground",null,r.kg("editorDimmedLineNumber","Color of the final editor line when editor.renderFinalNewline is set to dimmed.")),(0,s.x1A)("editorRuler.foreground",{dark:"#5A5A5A",light:i.Q1.lightgrey,hcDark:i.Q1.white,hcLight:"#292929"},r.kg("editorRuler","Color of the editor rulers.")),(0,s.x1A)("editorCodeLens.foreground",{dark:"#999999",light:"#919191",hcDark:"#999999",hcLight:"#292929"},r.kg("editorCodeLensForeground","Foreground color of editor CodeLens")),(0,s.x1A)("editorBracketMatch.background",{dark:"#0064001a",light:"#0064001a",hcDark:"#0064001a",hcLight:"#0000"},r.kg("editorBracketMatchBackground","Background color behind matching brackets")),(0,s.x1A)("editorBracketMatch.border",{dark:"#888",light:"#B9B9B9",hcDark:s.b1q,hcLight:s.b1q},r.kg("editorBracketMatchBorder","Color for matching brackets boxes")),(0,s.x1A)("editorOverviewRuler.border",{dark:"#7f7f7f4d",light:"#7f7f7f4d",hcDark:"#7f7f7f4d",hcLight:"#666666"},r.kg("editorOverviewRulerBorder","Color of the overview ruler border.")),(0,s.x1A)("editorOverviewRuler.background",null,r.kg("editorOverviewRulerBackground","Background color of the editor overview ruler.")),(0,s.x1A)("editorGutter.background",s.YtV,r.kg("editorGutter","Background color of the editor gutter. The gutter contains the glyph margins and the line numbers.")),(0,s.x1A)("editorUnnecessaryCode.border",{dark:null,light:null,hcDark:i.Q1.fromHex("#fff").transparent(.8),hcLight:s.b1q},r.kg("unnecessaryCodeBorder","Border color of unnecessary (unused) source code in the editor.")),(0,s.x1A)("editorUnnecessaryCode.opacity",{dark:i.Q1.fromHex("#000a"),light:i.Q1.fromHex("#0007"),hcDark:null,hcLight:null},r.kg("unnecessaryCodeOpacity","Opacity of unnecessary (unused) source code in the editor. For example, \"#000000c0\" will render the code with 75% opacity. For high contrast themes, use the 'editorUnnecessaryCode.border' theme color to underline unnecessary code instead of fading it out.")),(0,s.x1A)("editorGhostText.border",{dark:null,light:null,hcDark:i.Q1.fromHex("#fff").transparent(.8),hcLight:i.Q1.fromHex("#292929").transparent(.8)},r.kg("editorGhostTextBorder","Border color of ghost text in the editor.")),(0,s.x1A)("editorGhostText.foreground",{dark:i.Q1.fromHex("#ffffff56"),light:i.Q1.fromHex("#0007"),hcDark:null,hcLight:null},r.kg("editorGhostTextForeground","Foreground color of the ghost text in the editor.")),(0,s.x1A)("editorGhostText.background",null,r.kg("editorGhostTextBackground","Background color of the ghost text in the editor.")),new i.Q1(new i.bU(0,122,204,.6))),m=((0,s.x1A)("editorOverviewRuler.rangeHighlightForeground",f,r.kg("overviewRulerRangeHighlight","Overview ruler marker color for range highlights. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1A)("editorOverviewRuler.errorForeground",{dark:new i.Q1(new i.bU(255,18,18,.7)),light:new i.Q1(new i.bU(255,18,18,.7)),hcDark:new i.Q1(new i.bU(255,50,50,1)),hcLight:"#B5200D"},r.kg("overviewRuleError","Overview ruler marker color for errors."))),p=(0,s.x1A)("editorOverviewRuler.warningForeground",{dark:s.Hng,light:s.Hng,hcDark:s.Stt,hcLight:s.Stt},r.kg("overviewRuleWarning","Overview ruler marker color for warnings.")),b=(0,s.x1A)("editorOverviewRuler.infoForeground",{dark:s.pOz,light:s.pOz,hcDark:s.IIb,hcLight:s.IIb},r.kg("overviewRuleInfo","Overview ruler marker color for infos.")),_=(0,s.x1A)("editorBracketHighlight.foreground1",{dark:"#FFD700",light:"#0431FAFF",hcDark:"#FFD700",hcLight:"#0431FAFF"},r.kg("editorBracketHighlightForeground1","Foreground color of brackets (1). Requires enabling bracket pair colorization.")),k=(0,s.x1A)("editorBracketHighlight.foreground2",{dark:"#DA70D6",light:"#319331FF",hcDark:"#DA70D6",hcLight:"#319331FF"},r.kg("editorBracketHighlightForeground2","Foreground color of brackets (2). Requires enabling bracket pair colorization.")),v=(0,s.x1A)("editorBracketHighlight.foreground3",{dark:"#179FFF",light:"#7B3814FF",hcDark:"#87CEFA",hcLight:"#7B3814FF"},r.kg("editorBracketHighlightForeground3","Foreground color of brackets (3). Requires enabling bracket pair colorization.")),C=(0,s.x1A)("editorBracketHighlight.foreground4","#00000000",r.kg("editorBracketHighlightForeground4","Foreground color of brackets (4). Requires enabling bracket pair colorization.")),y=(0,s.x1A)("editorBracketHighlight.foreground5","#00000000",r.kg("editorBracketHighlightForeground5","Foreground color of brackets (5). Requires enabling bracket pair colorization.")),L=(0,s.x1A)("editorBracketHighlight.foreground6","#00000000",r.kg("editorBracketHighlightForeground6","Foreground color of brackets (6). Requires enabling bracket pair colorization.")),w=(0,s.x1A)("editorBracketHighlight.unexpectedBracket.foreground",{dark:new i.Q1(new i.bU(255,18,18,.8)),light:new i.Q1(new i.bU(255,18,18,.8)),hcDark:"new Color(new RGBA(255, 50, 50, 1))",hcLight:"#B5200D"},r.kg("editorBracketHighlightUnexpectedBracketForeground","Foreground color of unexpected brackets."));(0,s.x1A)("editorBracketPairGuide.background1","#00000000",r.kg("editorBracketPairGuide.background1","Background color of inactive bracket pair guides (1). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background2","#00000000",r.kg("editorBracketPairGuide.background2","Background color of inactive bracket pair guides (2). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background3","#00000000",r.kg("editorBracketPairGuide.background3","Background color of inactive bracket pair guides (3). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background4","#00000000",r.kg("editorBracketPairGuide.background4","Background color of inactive bracket pair guides (4). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background5","#00000000",r.kg("editorBracketPairGuide.background5","Background color of inactive bracket pair guides (5). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.background6","#00000000",r.kg("editorBracketPairGuide.background6","Background color of inactive bracket pair guides (6). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground1","#00000000",r.kg("editorBracketPairGuide.activeBackground1","Background color of active bracket pair guides (1). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground2","#00000000",r.kg("editorBracketPairGuide.activeBackground2","Background color of active bracket pair guides (2). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground3","#00000000",r.kg("editorBracketPairGuide.activeBackground3","Background color of active bracket pair guides (3). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground4","#00000000",r.kg("editorBracketPairGuide.activeBackground4","Background color of active bracket pair guides (4). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground5","#00000000",r.kg("editorBracketPairGuide.activeBackground5","Background color of active bracket pair guides (5). Requires enabling bracket pair guides.")),(0,s.x1A)("editorBracketPairGuide.activeBackground6","#00000000",r.kg("editorBracketPairGuide.activeBackground6","Background color of active bracket pair guides (6). Requires enabling bracket pair guides.")),(0,s.x1A)("editorUnicodeHighlight.border",s.Hng,r.kg("editorUnicodeHighlight.border","Border color used to highlight unicode characters.")),(0,s.x1A)("editorUnicodeHighlight.background",s.whs,r.kg("editorUnicodeHighlight.background","Background color used to highlight unicode characters."));(0,o.zy)(((e,t)=>{const n=e.getColor(s.YtV),r=e.getColor(a),i=r&&!r.isTransparent()?r:n;i&&t.addRule(`.monaco-editor .inputarea.ime-input { background-color: ${i}; }`)}))},7550:(e,t,n)=>{"use strict";n.r(t),n.d(t,{IMarkerDecorationsService:()=>r});const r=(0,n(3591).u1)("markerDecorationsService")},7596:(e,t,n)=>{"use strict";n.r(t),n.d(t,{LanguageService:()=>O});var r=n(1234),i=n(1484),s=n(9259),o=n(9861),a=n(2083),l=n(3941);const c=(e,t)=>e===t;new WeakMap;class h{constructor(e,t,n){this.owner=e,this.debugNameSource=t,this.referenceFn=n}getDebugName(e){return function(e,t){const n=d.get(e);if(n)return n;const r=function(e,t){const n=d.get(e);if(n)return n;const r=t.owner?function(e){const t=f.get(e);if(t)return t;const n=function(e){const t=e.constructor;if(t)return t.name;return"Object"}(e);let r=g.get(n)??0;r++,g.set(n,r);const i=1===r?n:`${n}#${r}`;return f.set(e,i),i}(t.owner)+".":"";let i;const s=t.debugNameSource;if(void 0!==s){if("function"!==typeof s)return r+s;if(i=s(),void 0!==i)return r+i}const o=t.referenceFn;if(void 0!==o&&(i=m(o),void 0!==i))return r+i;if(void 0!==t.owner){const n=function(e,t){for(const n in e)if(e[n]===t)return n;return}(t.owner,e);if(void 0!==n)return r+n}return}(e,t);if(r){let t=u.get(r)??0;t++,u.set(r,t);const n=1===t?r:`${r}#${t}`;return d.set(e,n),n}return}(e,this)}}const u=new Map,d=new WeakMap;const g=new Map,f=new WeakMap;function m(e){const t=e.toString(),n=/\/\*\*\s*@description\s*([^*]*)\*\//.exec(t),r=n?n[1]:void 0;return r?.trim()}let p,b,_,k;function v(){return p}class C{get TChange(){return null}reportChanges(){this.get()}read(e){return e?e.readObservable(this):this.get()}map(e,t){const n=void 0===t?void 0:e,r=void 0===t?e:t;return k({owner:n,debugName:()=>{const e=m(r);if(void 0!==e)return e;const t=/^\s*\(?\s*([a-zA-Z_$][a-zA-Z_$0-9]*)\s*\)?\s*=>\s*\1(?:\??)\.([a-zA-Z_$][a-zA-Z_$0-9]*)\s*$/.exec(r.toString());return t?`${this.debugName}.${t[2]}`:n?void 0:`${this.debugName} (mapped)`},debugReferenceFn:r},(e=>r(this.read(e),e)))}flatten(){return k({owner:void 0,debugName:()=>`${this.debugName} (flattened)`},(e=>this.read(e).read(e)))}recomputeInitiallyAndOnChange(e,t){return e.add(b(this,t)),this}keepObserved(e){return e.add(_(this)),this}}class y extends C{constructor(){super(...arguments),this.observers=new Set}addObserver(e){const t=this.observers.size;this.observers.add(e),0===t&&this.onFirstObserverAdded()}removeObserver(e){this.observers.delete(e)&&0===this.observers.size&&this.onLastObserverRemoved()}onFirstObserverAdded(){}onLastObserverRemoved(){}}function L(e,t){const n=new w(e,t);try{e(n)}finally{n.finish()}}class w{constructor(e,t){this._fn=e,this._getDebugName=t,this.updatingObservers=[],v()?.handleBeginTransaction(this)}getDebugName(){return this._getDebugName?this._getDebugName():m(this._fn)}updateObserver(e,t){this.updatingObservers.push({observer:e,observable:t}),e.beginUpdate(t)}finish(){const e=this.updatingObservers;for(let t=0;t`}beginUpdate(e){this.updateCount++;const t=1===this.updateCount;if(3===this.state&&(this.state=1,!t))for(const n of this.observers)n.handlePossibleChange(this);if(t)for(const n of this.observers)n.beginUpdate(this)}endUpdate(e){if(this.updateCount--,0===this.updateCount){const e=[...this.observers];for(const t of e)t.endUpdate(this)}(0,S.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){if(3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){this.state=1;for(const e of this.observers)e.handlePossibleChange(this)}}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){const n=!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary),r=3===this.state;if(n&&(1===this.state||r)&&(this.state=2,r))for(const e of this.observers)e.handlePossibleChange(this)}}readObservable(e){e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}addObserver(e){const t=!this.observers.has(e)&&this.updateCount>0;super.addObserver(e),t&&e.beginUpdate(this)}removeObserver(e){const t=this.observers.has(e)&&this.updateCount>0;super.removeObserver(e),t&&e.endUpdate(this)}}function E(e){return new N(new h(void 0,void 0,e),e,void 0,void 0)}class N{get debugName(){return this._debugNameData.getDebugName(this)??"(anonymous)"}constructor(e,t,n,r){this._debugNameData=e,this._runFn=t,this.createChangeSummary=n,this._handleChange=r,this.state=2,this.updateCount=0,this.disposed=!1,this.dependencies=new Set,this.dependenciesToBeRemoved=new Set,this.changeSummary=this.createChangeSummary?.(),v()?.handleAutorunCreated(this),this._runIfNeeded(),(0,i.Ay)(this)}dispose(){this.disposed=!0;for(const e of this.dependencies)e.removeObserver(this);this.dependencies.clear(),(0,i.VD)(this)}_runIfNeeded(){if(3===this.state)return;const e=this.dependenciesToBeRemoved;this.dependenciesToBeRemoved=this.dependencies,this.dependencies=e,this.state=3;const t=this.disposed;try{if(!t){v()?.handleAutorunTriggered(this);const e=this.changeSummary;this.changeSummary=this.createChangeSummary?.(),this._runFn(this,e)}}finally{t||v()?.handleAutorunFinished(this);for(const e of this.dependenciesToBeRemoved)e.removeObserver(this);this.dependenciesToBeRemoved.clear()}}toString(){return`Autorun<${this.debugName}>`}beginUpdate(){3===this.state&&(this.state=1),this.updateCount++}endUpdate(){if(1===this.updateCount)do{if(1===this.state){this.state=3;for(const e of this.dependencies)if(e.reportChanges(),2===this.state)break}this._runIfNeeded()}while(3!==this.state);this.updateCount--,(0,S.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)&&(this.state=1)}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){(!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary))&&(this.state=2)}}readObservable(e){if(this.disposed)return e.get();e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}}!function(e){e.Observer=N}(E||(E={}));function T(...e){let t,n,r;return 3===e.length?[t,n,r]=e:[n,r]=e,new A(new h(t,void 0,r),n,r,(()=>A.globalTransaction),c)}class A extends y{constructor(e,t,n,r,i){super(),this._debugNameData=e,this.event=t,this._getValue=n,this._getTransaction=r,this._equalityComparator=i,this.hasValue=!1,this.handleEvent=e=>{const t=this._getValue(e),n=this.value,r=!this.hasValue||!this._equalityComparator(n,t);let i=!1;r&&(this.value=t,this.hasValue&&(i=!0,function(e,t,n){e?t(e):L(t,n)}(this._getTransaction(),(e=>{v()?.handleFromEventObservableTriggered(this,{oldValue:n,newValue:t,change:void 0,didChange:r,hadValue:this.hasValue});for(const t of this.observers)e.updateObserver(t,this),t.handleChange(this,void 0)}),(()=>{const e=this.getDebugName();return"Event fired"+(e?`: ${e}`:"")}))),this.hasValue=!0),i||v()?.handleFromEventObservableTriggered(this,{oldValue:n,newValue:t,change:void 0,didChange:r,hadValue:this.hasValue})}}getDebugName(){return this._debugNameData.getDebugName(this)}get debugName(){const e=this.getDebugName();return"From Event"+(e?`: ${e}`:"")}onFirstObserverAdded(){this.subscription=this.event(this.handleEvent)}onLastObserverRemoved(){this.subscription.dispose(),this.subscription=void 0,this.hasValue=!1,this.value=void 0}get(){if(this.subscription)return this.hasValue||this.handleEvent(void 0),this.value;return this._getValue(void 0)}}!function(e){e.Observer=A,e.batchEventsGlobally=function(e,t){let n=!1;void 0===A.globalTransaction&&(A.globalTransaction=e,n=!0);try{t()}finally{n&&(A.globalTransaction=void 0)}}}(T||(T={}));!function(e){_=e}((function(e){const t=new I(!1,void 0);return e.addObserver(t),(0,i.s)((()=>{e.removeObserver(t)}))})),function(e){b=e}((function(e,t){const n=new I(!0,t);return e.addObserver(n),t?t(e.get()):e.reportChanges(),(0,i.s)((()=>{e.removeObserver(n)}))}));class I{constructor(e,t){this._forceRecompute=e,this._handleValue=t,this._counter=0}beginUpdate(e){this._counter++}endUpdate(e){this._counter--,0===this._counter&&this._forceRecompute&&(this._handleValue?this._handleValue(e.get()):e.reportChanges())}handlePossibleChange(e){}handleChange(e,t){}}n(4383);class O extends i.jG{static{this.instanceCount=0}constructor(e=!1){super(),this._onDidRequestBasicLanguageFeatures=this._register(new r.vl),this.onDidRequestBasicLanguageFeatures=this._onDidRequestBasicLanguageFeatures.event,this._onDidRequestRichLanguageFeatures=this._register(new r.vl),this.onDidRequestRichLanguageFeatures=this._onDidRequestRichLanguageFeatures.event,this._onDidChange=this._register(new r.vl({leakWarningThreshold:200})),this.onDidChange=this._onDidChange.event,this._requestedBasicLanguages=new Set,this._requestedRichLanguages=new Set,O.instanceCount++,this._registry=this._register(new s.LanguagesRegistry(!0,e)),this.languageIdCodec=this._registry.languageIdCodec,this._register(this._registry.onDidChange((()=>this._onDidChange.fire())))}dispose(){O.instanceCount--,super.dispose()}isRegisteredLanguageId(e){return this._registry.isRegisteredLanguageId(e)}getLanguageIdByLanguageName(e){return this._registry.getLanguageIdByLanguageName(e)}getLanguageIdByMimeType(e){return this._registry.getLanguageIdByMimeType(e)}guessLanguageIdByFilepathOrFirstLine(e,t){const n=this._registry.guessLanguageIdByFilepathOrFirstLine(e,t);return(0,o.Fy)(n,null)}createById(e){return new M(this.onDidChange,(()=>this._createAndGetLanguageIdentifier(e)))}createByFilepathOrFirstLine(e,t){return new M(this.onDidChange,(()=>{const n=this.guessLanguageIdByFilepathOrFirstLine(e,t);return this._createAndGetLanguageIdentifier(n)}))}_createAndGetLanguageIdentifier(e){return e&&this.isRegisteredLanguageId(e)||(e=l.vH),e}requestBasicLanguageFeatures(e){this._requestedBasicLanguages.has(e)||(this._requestedBasicLanguages.add(e),this._onDidRequestBasicLanguageFeatures.fire(e))}requestRichLanguageFeatures(e){this._requestedRichLanguages.has(e)||(this._requestedRichLanguages.add(e),this.requestBasicLanguageFeatures(e),a.dG.getOrCreate(e),this._onDidRequestRichLanguageFeatures.fire(e))}}class M{constructor(e,t){this._value=T(this,e,(()=>t())),this.onDidChange=r.Jh.fromObservable(this._value)}get languageId(){return this._value.get()}}},7614:(e,t,n)=>{var r={"./editorBaseApi":4272,"./editorBaseApi.js":4272,"./editorSimpleWorker":5196,"./editorSimpleWorker.js":5196,"./editorWorker":920,"./editorWorker.js":920,"./editorWorkerHost":718,"./editorWorkerHost.js":718,"./findSectionHeaders":6691,"./findSectionHeaders.js":6691,"./getIconClasses":5628,"./getIconClasses.js":5628,"./languageFeatureDebounce":8709,"./languageFeatureDebounce.js":8709,"./languageFeatures":6942,"./languageFeatures.js":6942,"./languageFeaturesService":2661,"./languageFeaturesService.js":2661,"./languageService":7596,"./languageService.js":7596,"./languagesAssociations":9908,"./languagesAssociations.js":9908,"./languagesRegistry":9259,"./languagesRegistry.js":9259,"./markerDecorations":7550,"./markerDecorations.js":7550,"./markerDecorationsService":448,"./markerDecorationsService.js":448,"./model":3750,"./model.js":3750,"./modelService":1773,"./modelService.js":1773,"./resolverService":8938,"./resolverService.js":8938,"./semanticTokensDto":8232,"./semanticTokensDto.js":8232,"./semanticTokensProviderStyling":5538,"./semanticTokensProviderStyling.js":5538,"./semanticTokensStyling":4243,"./semanticTokensStyling.js":4243,"./semanticTokensStylingService":7004,"./semanticTokensStylingService.js":7004,"./textModelSync/textModelSync.impl":796,"./textModelSync/textModelSync.impl.js":796,"./textModelSync/textModelSync.protocol":8868,"./textModelSync/textModelSync.protocol.js":8868,"./textResourceConfiguration":360,"./textResourceConfiguration.js":360,"./treeSitterParserService":4432,"./treeSitterParserService.js":4432,"./treeViewsDnd":6723,"./treeViewsDnd.js":6723,"./treeViewsDndService":9100,"./treeViewsDndService.js":9100,"./unicodeTextModelHighlighter":4855,"./unicodeTextModelHighlighter.js":4855,"monaco-editor/esm/vs/editor/common/services/editorBaseApi":4272,"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":4272,"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":5196,"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":5196,"monaco-editor/esm/vs/editor/common/services/editorWorker":920,"monaco-editor/esm/vs/editor/common/services/editorWorker.js":920,"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":718,"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":718,"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":6691,"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":6691,"monaco-editor/esm/vs/editor/common/services/getIconClasses":5628,"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":5628,"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":8709,"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":8709,"monaco-editor/esm/vs/editor/common/services/languageFeatures":6942,"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":6942,"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":2661,"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":2661,"monaco-editor/esm/vs/editor/common/services/languageService":7596,"monaco-editor/esm/vs/editor/common/services/languageService.js":7596,"monaco-editor/esm/vs/editor/common/services/languagesAssociations":9908,"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":9908,"monaco-editor/esm/vs/editor/common/services/languagesRegistry":9259,"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":9259,"monaco-editor/esm/vs/editor/common/services/markerDecorations":7550,"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":7550,"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":448,"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":448,"monaco-editor/esm/vs/editor/common/services/model":3750,"monaco-editor/esm/vs/editor/common/services/model.js":3750,"monaco-editor/esm/vs/editor/common/services/modelService":1773,"monaco-editor/esm/vs/editor/common/services/modelService.js":1773,"monaco-editor/esm/vs/editor/common/services/resolverService":8938,"monaco-editor/esm/vs/editor/common/services/resolverService.js":8938,"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":8232,"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":8232,"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":5538,"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":5538,"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":4243,"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":4243,"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":7004,"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":7004,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":796,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":796,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":8868,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":8868,"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":360,"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":360,"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":4432,"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":4432,"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":6723,"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":6723,"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":9100,"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":9100,"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":4855,"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":4855};function i(e){var t=s(e);return n(t)}function s(e){if(!n.o(r,e)){var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}return r[e]}i.keys=function(){return Object.keys(r)},i.resolve=s,e.exports=i,i.id=7614},7661:(e,t,n)=>{"use strict";function r(e,t){const n=Math.pow(10,t);return Math.round(e*n)/n}n.d(t,{Q1:()=>a,bU:()=>i,hB:()=>s});class i{constructor(e,t,n,i=1){this._rgbaBrand=void 0,this.r=0|Math.min(255,Math.max(0,e)),this.g=0|Math.min(255,Math.max(0,t)),this.b=0|Math.min(255,Math.max(0,n)),this.a=r(Math.max(Math.min(1,i),0),3)}static equals(e,t){return e.r===t.r&&e.g===t.g&&e.b===t.b&&e.a===t.a}}class s{constructor(e,t,n,i){this._hslaBrand=void 0,this.h=0|Math.max(Math.min(360,e),0),this.s=r(Math.max(Math.min(1,t),0),3),this.l=r(Math.max(Math.min(1,n),0),3),this.a=r(Math.max(Math.min(1,i),0),3)}static equals(e,t){return e.h===t.h&&e.s===t.s&&e.l===t.l&&e.a===t.a}static fromRGBA(e){const t=e.r/255,n=e.g/255,r=e.b/255,i=e.a,o=Math.max(t,n,r),a=Math.min(t,n,r);let l=0,c=0;const h=(a+o)/2,u=o-a;if(u>0){switch(c=Math.min(h<=.5?u/(2*h):u/(2-2*h),1),o){case t:l=(n-r)/u+(n1&&(n-=1),n<1/6?e+6*(t-e)*n:n<.5?t:n<2/3?e+(t-e)*(2/3-n)*6:e}static toRGBA(e){const t=e.h/360,{s:n,l:r,a:o}=e;let a,l,c;if(0===n)a=l=c=r;else{const e=r<.5?r*(1+n):r+n-r*n,i=2*r-e;a=s._hue2rgb(i,e,t+1/3),l=s._hue2rgb(i,e,t),c=s._hue2rgb(i,e,t-1/3)}return new i(Math.round(255*a),Math.round(255*l),Math.round(255*c),o)}}class o{constructor(e,t,n,i){this._hsvaBrand=void 0,this.h=0|Math.max(Math.min(360,e),0),this.s=r(Math.max(Math.min(1,t),0),3),this.v=r(Math.max(Math.min(1,n),0),3),this.a=r(Math.max(Math.min(1,i),0),3)}static equals(e,t){return e.h===t.h&&e.s===t.s&&e.v===t.v&&e.a===t.a}static fromRGBA(e){const t=e.r/255,n=e.g/255,r=e.b/255,i=Math.max(t,n,r),s=i-Math.min(t,n,r),a=0===i?0:s/i;let l;return l=0===s?0:i===t?((n-r)/s%6+6)%6:i===n?(r-t)/s+2:(t-n)/s+4,new o(Math.round(60*l),a,i,e.a)}static toRGBA(e){const{h:t,s:n,v:r,a:s}=e,o=r*n,a=o*(1-Math.abs(t/60%2-1)),l=r-o;let[c,h,u]=[0,0,0];return t<60?(c=o,h=a):t<120?(c=a,h=o):t<180?(h=o,u=a):t<240?(h=a,u=o):t<300?(c=a,u=o):t<=360&&(c=o,u=a),c=Math.round(255*(c+l)),h=Math.round(255*(h+l)),u=Math.round(255*(u+l)),new i(c,h,u,s)}}class a{static fromHex(e){return a.Format.CSS.parseHex(e)||a.red}static equals(e,t){return!e&&!t||!(!e||!t)&&e.equals(t)}get hsla(){return this._hsla?this._hsla:s.fromRGBA(this.rgba)}get hsva(){return this._hsva?this._hsva:o.fromRGBA(this.rgba)}constructor(e){if(!e)throw new Error("Color needs a value");if(e instanceof i)this.rgba=e;else if(e instanceof s)this._hsla=e,this.rgba=s.toRGBA(e);else{if(!(e instanceof o))throw new Error("Invalid color ctor argument");this._hsva=e,this.rgba=o.toRGBA(e)}}equals(e){return!!e&&i.equals(this.rgba,e.rgba)&&s.equals(this.hsla,e.hsla)&&o.equals(this.hsva,e.hsva)}getRelativeLuminance(){return r(.2126*a._relativeLuminanceForComponent(this.rgba.r)+.7152*a._relativeLuminanceForComponent(this.rgba.g)+.0722*a._relativeLuminanceForComponent(this.rgba.b),4)}static _relativeLuminanceForComponent(e){const t=e/255;return t<=.03928?t/12.92:Math.pow((t+.055)/1.055,2.4)}isLighter(){return(299*this.rgba.r+587*this.rgba.g+114*this.rgba.b)/1e3>=128}isLighterThan(e){return this.getRelativeLuminance()>e.getRelativeLuminance()}isDarkerThan(e){return this.getRelativeLuminance(){"use strict";n.d(t,{lt:()=>u,W5:()=>p,hB:()=>f,dr:()=>d,wC:()=>m});var r=n(1508),i=n(4320),s=n(534);class o extends s.V{constructor(e,t){super(0),this._segmenter=null,this._cachedLine=null,this._cachedSegments=[],this.intlSegmenterLocales=t,this.intlSegmenterLocales.length>0?this._segmenter=new Intl.Segmenter(this.intlSegmenterLocales,{granularity:"word"}):this._segmenter=null;for(let n=0,r=e.length;nt)break;n=r}return n}findNextIntlWordAtOrAfterOffset(e,t){for(const n of this._getIntlSegmenterWordsOnLine(e))if(!(n.index=n)break;const r=e.charCodeAt(t);if(110===r||114===r||87===r)return!0}}return!1}(this.searchString):this.searchString.indexOf("\n")>=0;let t=null;try{t=r.OS(this.searchString,this.isRegex,{matchCase:this.matchCase,wholeWord:!1,multiline:e,global:!0,unicode:!0})}catch(i){return null}if(!t)return null;let n=!this.isRegex&&!e;return n&&this.searchString.toLowerCase()!==this.searchString.toUpperCase()&&(n=this.matchCase),new h.L5(t,this.wordSeparators?function(e,t){const n=`${e}/${t.join(",")}`;let r=a.get(n);return r||(r=new o(e,t),a.set(n,r)),r}(this.wordSeparators,[]):null,n?this.searchString:null)}}function d(e,t,n){if(!n)return new h.Dg(e,null);const r=[];for(let i=0,s=t.length;i=e?r=i-1:t[i+1]>=e?(n=i,r=i):n=i+1}return n+1}}class f{static findMatches(e,t,n,r,i){const s=t.parseSearchRequest();return s?s.regex.multiline?this._doFindMatchesMultiline(e,n,new p(s.wordSeparators,s.regex),r,i):this._doFindMatchesLineByLine(e,n,s,r,i):[]}static _getMultilineMatchRange(e,t,n,r,i,s){let o,a,l=0;if(r?(l=r.findLineFeedCountBeforeOffset(i),o=t+i+l):o=t+i,r){const e=r.findLineFeedCountBeforeOffset(i+s.length)-l;a=o+s.length+e}else a=o+s.length;const h=e.getPositionAt(o),u=e.getPositionAt(a);return new c.Q(h.lineNumber,h.column,u.lineNumber,u.column)}static _doFindMatchesMultiline(e,t,n,r,i){const s=e.getOffsetAt(t.getStartPosition()),o=e.getValueInRange(t,1),a="\r\n"===e.getEOL()?new g(o):null,l=[];let c,h=0;for(n.reset(0);c=n.next(o);)if(l[h++]=d(this._getMultilineMatchRange(e,s,o,a,c.index,c[0]),c,r),h>=i)return l;return l}static _doFindMatchesLineByLine(e,t,n,r,i){const s=[];let o=0;if(t.startLineNumber===t.endLineNumber){const a=e.getLineContent(t.startLineNumber).substring(t.startColumn-1,t.endColumn-1);return o=this._findMatchesInLine(n,a,t.startLineNumber,t.startColumn-1,o,s,r,i),s}const a=e.getLineContent(t.startLineNumber).substring(t.startColumn-1);o=this._findMatchesInLine(n,a,t.startLineNumber,t.startColumn-1,o,s,r,i);for(let l=t.startLineNumber+1;l=a))return i;return i}const u=new p(e.wordSeparators,e.regex);let g;u.reset(0);do{if(g=u.next(t),g&&(s[i++]=d(new c.Q(n,g.index+1+r,n,g.index+1+g[0].length+r),g,o),i>=a))return i}while(g);return i}static findNextMatch(e,t,n,r){const i=t.parseSearchRequest();if(!i)return null;const s=new p(i.wordSeparators,i.regex);return i.regex.multiline?this._doFindNextMatchMultiline(e,n,s,r):this._doFindNextMatchLineByLine(e,n,s,r)}static _doFindNextMatchMultiline(e,t,n,r){const i=new l.y(t.lineNumber,1),s=e.getOffsetAt(i),o=e.getLineCount(),a=e.getValueInRange(new c.Q(i.lineNumber,i.column,o,e.getLineMaxColumn(o)),1),h="\r\n"===e.getEOL()?new g(a):null;n.reset(t.column-1);const u=n.next(a);return u?d(this._getMultilineMatchRange(e,s,a,h,u.index,u[0]),u,r):1!==t.lineNumber||1!==t.column?this._doFindNextMatchMultiline(e,new l.y(1,1),n,r):null}static _doFindNextMatchLineByLine(e,t,n,r){const i=e.getLineCount(),s=t.lineNumber,o=e.getLineContent(s),a=this._findFirstMatchInLine(n,o,s,t.column,r);if(a)return a;for(let l=1;l<=i;l++){const t=(s+l-1)%i,o=e.getLineContent(t+1),a=this._findFirstMatchInLine(n,o,t+1,1,r);if(a)return a}return null}static _findFirstMatchInLine(e,t,n,r,i){e.reset(r-1);const s=e.next(t);return s?d(new c.Q(n,s.index+1,n,s.index+1+s[0].length),s,i):null}static findPreviousMatch(e,t,n,r){const i=t.parseSearchRequest();if(!i)return null;const s=new p(i.wordSeparators,i.regex);return i.regex.multiline?this._doFindPreviousMatchMultiline(e,n,s,r):this._doFindPreviousMatchLineByLine(e,n,s,r)}static _doFindPreviousMatchMultiline(e,t,n,r){const i=this._doFindMatchesMultiline(e,new c.Q(1,1,t.lineNumber,t.column),n,r,9990);if(i.length>0)return i[i.length-1];const s=e.getLineCount();return t.lineNumber!==s||t.column!==e.getLineMaxColumn(s)?this._doFindPreviousMatchMultiline(e,new l.y(s,e.getLineMaxColumn(s)),n,r):null}static _doFindPreviousMatchLineByLine(e,t,n,r){const i=e.getLineCount(),s=t.lineNumber,o=e.getLineContent(s).substring(0,t.column-1),a=this._findLastMatchInLine(n,o,s,r);if(a)return a;for(let l=1;l<=i;l++){const t=(i+s-l-1)%i,o=e.getLineContent(t+1),a=this._findLastMatchInLine(n,o,t+1,r);if(a)return a}return null}static _findLastMatchInLine(e,t,n,r){let i,s=null;for(e.reset(0);i=e.next(t);)s=d(new c.Q(n,i.index+1,n,i.index+1+i[0].length),i,r);return s}}function m(e,t,n,r,i){return function(e,t,n,r,i){if(0===r)return!0;const s=t.charCodeAt(r-1);if(0!==e.get(s))return!0;if(13===s||10===s)return!0;if(i>0){const n=t.charCodeAt(r);if(0!==e.get(n))return!0}return!1}(e,t,0,r,i)&&function(e,t,n,r,i){if(r+i===n)return!0;const s=t.charCodeAt(r+i);if(0!==e.get(s))return!0;if(13===s||10===s)return!0;if(i>0){const n=t.charCodeAt(r+i-1);if(0!==e.get(n))return!0}return!1}(e,t,n,r,i)}class p{constructor(e,t){this._wordSeparators=e,this._searchRegex=t,this._prevMatchStartIndex=-1,this._prevMatchLength=0}reset(e){this._searchRegex.lastIndex=e,this._prevMatchStartIndex=-1,this._prevMatchLength=0}next(e){const t=e.length;let n;do{if(this._prevMatchStartIndex+this._prevMatchLength===t)return null;if(n=this._searchRegex.exec(e),!n)return null;const i=n.index,s=n[0].length;if(i===this._prevMatchStartIndex&&s===this._prevMatchLength){if(0===s){r.Z5(e,t,this._searchRegex.lastIndex)>65535?this._searchRegex.lastIndex+=2:this._searchRegex.lastIndex+=1;continue}return null}if(this._prevMatchStartIndex=i,this._prevMatchLength=s,!this._wordSeparators||m(this._wordSeparators,e,t,i,s))return n}while(n);return null}}},8067:(e,t,n)=>{"use strict";n.d(t,{H8:()=>P,HZ:()=>T,OS:()=>R,UP:()=>j,_p:()=>M,cm:()=>F,gm:()=>V,ib:()=>N,j9:()=>E,lg:()=>A,nr:()=>z,uF:()=>S,zx:()=>x});var r=n(8209);const i="en";let s,o,a=!1,l=!1,c=!1,h=!1,u=!1,d=!1,g=!1,f=!1,m=!1,p=!1,b=null,_=null,k=null;const v=globalThis;let C;"undefined"!==typeof v.vscode&&"undefined"!==typeof v.vscode.process?C=v.vscode.process:"undefined"!==typeof process&&"string"===typeof process?.versions?.node&&(C=process);const y="string"===typeof C?.versions?.electron,L=y&&"renderer"===C?.type;if("object"===typeof C){a="win32"===C.platform,l="darwin"===C.platform,c="linux"===C.platform,h=c&&!!C.env.SNAP&&!!C.env.SNAP_REVISION,g=y,m=!!C.env.CI||!!C.env.BUILD_ARTIFACTSTAGINGDIRECTORY,s=i,b=i;const e=C.env.VSCODE_NLS_CONFIG;if(e)try{const t=JSON.parse(e);s=t.userLocale,_=t.osLocale,b=t.resolvedLanguage||i,k=t.languagePack?.translationsConfigFile}catch(q){}u=!0}else"object"!==typeof navigator||L?console.error("Unable to resolve platform."):(o=navigator.userAgent,a=o.indexOf("Windows")>=0,l=o.indexOf("Macintosh")>=0,f=(o.indexOf("Macintosh")>=0||o.indexOf("iPad")>=0||o.indexOf("iPhone")>=0)&&!!navigator.maxTouchPoints&&navigator.maxTouchPoints>0,c=o.indexOf("Linux")>=0,p=o?.indexOf("Mobi")>=0,d=!0,b=r.i8()||i,s=navigator.language.toLowerCase(),_=s);let w=0;l?w=1:a?w=3:c&&(w=2);const S=a,x=l,E=c,N=u,T=d,A=d&&"function"===typeof v.importScripts?v.origin:void 0,I=o,O="function"===typeof v.postMessage&&!v.importScripts,M=(()=>{if(O){const e=[];v.addEventListener("message",(t=>{if(t.data&&t.data.vscodeScheduleAsyncWork)for(let n=0,r=e.length;n{const r=++t;e.push({id:r,callback:n}),v.postMessage({vscodeScheduleAsyncWork:r},"*")}}return e=>setTimeout(e)})(),R=l||f?2:a?1:3;let D=!0,B=!1;function F(){if(!B){B=!0;const e=new Uint8Array(2);e[0]=1,e[1]=2;const t=new Uint16Array(e.buffer);D=513===t[0]}return D}const P=!!(I&&I.indexOf("Chrome")>=0),V=!!(I&&I.indexOf("Firefox")>=0),z=!!(!P&&I&&I.indexOf("Safari")>=0),j=!!(I&&I.indexOf("Edg/")>=0);I&&I.indexOf("Android")},8209:(e,t,n)=>{"use strict";function r(){return globalThis._VSCODE_NLS_LANGUAGE}n.d(t,{i8:()=>r,kg:()=>o});const i="pseudo"===r()||"undefined"!==typeof document&&document.location&&document.location.hash.indexOf("pseudo=true")>=0;function s(e,t){let n;return n=0===t.length?e:e.replace(/\{(\d+)\}/g,((e,n)=>{const r=n[0],i=t[r];let s=e;return"string"===typeof i?s=i:"number"!==typeof i&&"boolean"!==typeof i&&void 0!==i&&null!==i||(s=String(i)),s})),i&&(n="\uff3b"+n.replace(/[aouei]/g,"$&$&")+"\uff3d"),n}function o(e,t,...n){return s("number"===typeof e?a(e,t):t,n)}function a(e,t){const n=globalThis._VSCODE_NLS_MESSAGES?.[e];if("string"!==typeof n){if("string"===typeof t)return t;throw new Error(`!!! NLS MISSING: ${e} !!!`)}return n}},8232:(e,t,n)=>{"use strict";n.r(t),n.d(t,{encodeSemanticTokensDto:()=>s});var r=n(1674),i=n(8067);function s(e){const t=new Uint32Array(function(e){let t=0;if(t+=2,"full"===e.type)t+=1+e.data.length;else{t+=1,t+=3*e.deltas.length;for(const n of e.deltas)n.data&&(t+=n.data.length)}return t}(e));let n=0;if(t[n++]=e.id,"full"===e.type)t[n++]=1,t[n++]=e.data.length,t.set(e.data,n),n+=e.data.length;else{t[n++]=2,t[n++]=e.deltas.length;for(const r of e.deltas)t[n++]=r.start,t[n++]=r.deleteCount,r.data?(t[n++]=r.data.length,t.set(r.data,n),n+=r.data.length):t[n++]=0}return function(e){const t=new Uint8Array(e.buffer,e.byteOffset,4*e.length);return i.cm()||function(e){for(let t=0,n=e.length;t{"use strict";n.d(t,{W:()=>i});const r=globalThis.performance&&"function"===typeof globalThis.performance.now;class i{static create(e){return new i(e)}constructor(e){this._now=r&&!1===e?Date.now:globalThis.performance.now.bind(globalThis.performance),this._startTime=this._now(),this._stopTime=-1}stop(){this._stopTime=this._now()}reset(){this._startTime=this._now(),this._stopTime=-1}elapsed(){return-1!==this._stopTime?this._stopTime-this._startTime:this._now()-this._startTime}}},8447:(e,t,n)=>{"use strict";n.d(t,{Qi:()=>a});var r=n(1234);const i=Object.freeze((function(e,t){const n=setTimeout(e.bind(t),0);return{dispose(){clearTimeout(n)}}}));var s;!function(e){e.isCancellationToken=function(t){return t===e.None||t===e.Cancelled||(t instanceof o||!(!t||"object"!==typeof t)&&("boolean"===typeof t.isCancellationRequested&&"function"===typeof t.onCancellationRequested))},e.None=Object.freeze({isCancellationRequested:!1,onCancellationRequested:r.Jh.None}),e.Cancelled=Object.freeze({isCancellationRequested:!0,onCancellationRequested:i})}(s||(s={}));class o{constructor(){this._isCancelled=!1,this._emitter=null}cancel(){this._isCancelled||(this._isCancelled=!0,this._emitter&&(this._emitter.fire(void 0),this.dispose()))}get isCancellationRequested(){return this._isCancelled}get onCancellationRequested(){return this._isCancelled?i:(this._emitter||(this._emitter=new r.vl),this._emitter.event)}dispose(){this._emitter&&(this._emitter.dispose(),this._emitter=null)}}class a{constructor(e){this._token=void 0,this._parentListener=void 0,this._parentListener=e&&e.onCancellationRequested(this.cancel,this)}get token(){return this._token||(this._token=new o),this._token}cancel(){this._token?this._token instanceof o&&this._token.cancel():this._token=s.Cancelled}dispose(e=!1){e&&this.cancel(),this._parentListener?.dispose(),this._token?this._token instanceof o&&this._token.dispose():this._token=s.None}}},8709:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ILanguageFeatureDebounceService:()=>m,LanguageFeatureDebounceService:()=>k});var r=n(5600),i=n(4320);function s(e,t,n){return Math.min(Math.max(e,t),n)}class o{constructor(){this._n=1,this._val=0}update(e){return this._val=this._val+(e-this._val)/this._n,this._n+=1,this._val}get value(){return this._val}}class a{constructor(e){this._n=0,this._val=0,this._values=[],this._index=0,this._sum=0,this._values=new Array(e),this._values.fill(0,0,e)}update(e){const t=this._values[this._index];return this._values[this._index]=e,this._index=(this._index+1)%this._values.length,this._sum-=t,this._sum+=e,this._n=0;a--)(i=e[a])&&(o=(s<3?i(o):s>3?i(t,n,o):i(t,n))||o);return s>3&&o&&Object.defineProperty(t,n,o),o},f=function(e,t){return function(n,r){t(n,r,e)}};const m=(0,l.u1)("ILanguageFeatureDebounceService");var p;!function(e){const t=new WeakMap;let n=0;e.of=function(e){let r=t.get(e);return void 0===r&&(r=++n,t.set(e,r)),r}}(p||(p={}));class b{constructor(e){this._default=e}get(e){return this._default}update(e,t){return this._default}default(){return this._default}}class _{constructor(e,t,n,r,s,o){this._logService=e,this._name=t,this._registry=n,this._default=r,this._min=s,this._max=o,this._cache=new i.qK(50,.7)}_key(e){return e.id+this._registry.all(e).reduce(((e,t)=>(0,r.sN)(p.of(t),e)),0)}get(e){const t=this._key(e),n=this._cache.get(t);return n?s(n.value,this._min,this._max):this.default()}update(e,t){const n=this._key(e);let r=this._cache.get(n);r||(r=new a(6),this._cache.set(n,r));const i=s(r.update(t),this._min,this._max);return(0,d.v$)(e.uri,"output")||this._logService.trace(`[DEBOUNCE: ${this._name}] for ${e.uri.toString()} is ${i}ms`),i}_overall(){const e=new o;for(const[,t]of this._cache)e.update(t.value);return e.value}default(){return s(0|this._overall()||this._default,this._min,this._max)}}let k=class{constructor(e,t){this._logService=e,this._data=new Map,this._isDev=t.isExtensionDevelopment||!t.isBuilt}for(e,t,n){const r=n?.min??50,i=n?.max??r**2,s=n?.key??void 0,o=`${p.of(e)},${r}${s?","+s:""}`;let a=this._data.get(o);return a||(this._isDev?(this._logService.debug(`[DEBOUNCE: ${t}] is disabled in developed mode`),a=new b(1.5*r)):a=new _(this._logService,t,e,0|this._overallAverage()||1.5*r,r,i),this._data.set(o,a)),a}_overallAverage(){const e=new o;for(const t of this._data.values())e.update(t.default());return e.value}};k=g([f(0,u.rr),f(1,c)],k),(0,h.v)(m,k,1)},8748:(e,t,n)=>{"use strict";n.d(t,{F:()=>s});var r=n(1234),i=n(6359);const s={JSONContribution:"base.contributions.json"};const o=new class{constructor(){this._onDidChangeSchema=new r.vl,this.schemasById={}}registerSchema(e,t){var n;this.schemasById[(n=e,n.length>0&&"#"===n.charAt(n.length-1)?n.substring(0,n.length-1):n)]=t,this._onDidChangeSchema.fire(e)}notifySchemaChanged(e){this._onDidChangeSchema.fire(e)}};i.O.add(s.JSONContribution,o)},8821:(e,t,n)=>{"use strict";n.d(t,{P8:()=>N,pD:()=>E,LC:()=>T,fj:()=>w,S8:()=>L,SA:()=>y,V8:()=>x,hd:()=>S,Vn:()=>A,IN:()=>v});var r=n(8067);let i;const s=globalThis.vscode;if("undefined"!==typeof s&&"undefined"!==typeof s.process){const e=s.process;i={get platform(){return e.platform},get arch(){return e.arch},get env(){return e.env},cwd:()=>e.cwd()}}else i="undefined"!==typeof process&&"string"===typeof process?.versions?.node?{get platform(){return process.platform},get arch(){return process.arch},get env(){return{NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}},cwd:()=>({NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}.VSCODE_CWD||process.cwd())}:{get platform(){return r.uF?"win32":r.zx?"darwin":"linux"},get arch(){},get env(){return{}},cwd:()=>"/"};const o=i.cwd,a=(i.env,i.platform),l=46,c=47,h=92,u=58;class d extends Error{constructor(e,t,n){let r;"string"===typeof t&&0===t.indexOf("not ")?(r="must not be",t=t.replace(/^not /,"")):r="must be";const i=-1!==e.indexOf(".")?"property":"argument";let s=`The "${e}" ${i} ${r} of type ${t}`;s+=". Received type "+typeof n,super(s),this.code="ERR_INVALID_ARG_TYPE"}}function g(e,t){if("string"!==typeof e)throw new d(t,"string",e)}const f="win32"===a;function m(e){return e===c||e===h}function p(e){return e===c}function b(e){return e>=65&&e<=90||e>=97&&e<=122}function _(e,t,n,r){let i="",s=0,o=-1,a=0,h=0;for(let u=0;u<=e.length;++u){if(u2){const e=i.lastIndexOf(n);-1===e?(i="",s=0):(i=i.slice(0,e),s=i.length-1-i.lastIndexOf(n)),o=u,a=0;continue}if(0!==i.length){i="",s=0,o=u,a=0;continue}}t&&(i+=i.length>0?`${n}..`:"..",s=2)}else i.length>0?i+=`${n}${e.slice(o+1,u)}`:i=e.slice(o+1,u),s=u-o-1;o=u,a=0}else h===l&&-1!==a?++a:a=-1}return i}function k(e,t){!function(e,t){if(null===e||"object"!==typeof e)throw new d(t,"Object",e)}(t,"pathObject");const n=t.dir||t.root,r=t.base||`${t.name||""}${i=t.ext,i?`${"."===i[0]?"":"."}${i}`:""}`;var i;return n?n===t.root?`${n}${r}`:`${n}${e}${r}`:r}const v={resolve(...e){let t="",n="",r=!1;for(let i=e.length-1;i>=-1;i--){let s;if(i>=0){if(s=e[i],g(s,`paths[${i}]`),0===s.length)continue}else 0===t.length?s=o():(s={NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}[`=${t}`]||o(),(void 0===s||s.slice(0,2).toLowerCase()!==t.toLowerCase()&&s.charCodeAt(2)===h)&&(s=`${t}\\`));const a=s.length;let l=0,c="",d=!1;const f=s.charCodeAt(0);if(1===a)m(f)&&(l=1,d=!0);else if(m(f))if(d=!0,m(s.charCodeAt(1))){let e=2,t=e;for(;e2&&m(s.charCodeAt(2))&&(d=!0,l=3));if(c.length>0)if(t.length>0){if(c.toLowerCase()!==t.toLowerCase())continue}else t=c;if(r){if(t.length>0)break}else if(n=`${s.slice(l)}\\${n}`,r=d,d&&t.length>0)break}return n=_(n,!r,"\\",m),r?`${t}\\${n}`:`${t}${n}`||"."},normalize(e){g(e,"path");const t=e.length;if(0===t)return".";let n,r=0,i=!1;const s=e.charCodeAt(0);if(1===t)return p(s)?"\\":e;if(m(s))if(i=!0,m(e.charCodeAt(1))){let i=2,s=i;for(;i2&&m(e.charCodeAt(2))&&(i=!0,r=3));let o=r0&&m(e.charCodeAt(t-1))&&(o+="\\"),void 0===n?i?`\\${o}`:o:i?`${n}\\${o}`:`${n}${o}`},isAbsolute(e){g(e,"path");const t=e.length;if(0===t)return!1;const n=e.charCodeAt(0);return m(n)||t>2&&b(n)&&e.charCodeAt(1)===u&&m(e.charCodeAt(2))},join(...e){if(0===e.length)return".";let t,n;for(let s=0;s0&&(void 0===t?t=n=r:t+=`\\${r}`)}if(void 0===t)return".";let r=!0,i=0;if("string"===typeof n&&m(n.charCodeAt(0))){++i;const e=n.length;e>1&&m(n.charCodeAt(1))&&(++i,e>2&&(m(n.charCodeAt(2))?++i:r=!1))}if(r){for(;i=2&&(t=`\\${t.slice(i)}`)}return v.normalize(t)},relative(e,t){if(g(e,"from"),g(t,"to"),e===t)return"";const n=v.resolve(e),r=v.resolve(t);if(n===r)return"";if((e=n.toLowerCase())===(t=r.toLowerCase()))return"";let i=0;for(;ii&&e.charCodeAt(s-1)===h;)s--;const o=s-i;let a=0;for(;aa&&t.charCodeAt(l-1)===h;)l--;const c=l-a,u=ou){if(t.charCodeAt(a+f)===h)return r.slice(a+f+1);if(2===f)return r.slice(a+f)}o>u&&(e.charCodeAt(i+f)===h?d=f:2===f&&(d=3)),-1===d&&(d=0)}let m="";for(f=i+d+1;f<=s;++f)f!==s&&e.charCodeAt(f)!==h||(m+=0===m.length?"..":"\\..");return a+=d,m.length>0?`${m}${r.slice(a,l)}`:(r.charCodeAt(a)===h&&++a,r.slice(a,l))},toNamespacedPath(e){if("string"!==typeof e||0===e.length)return e;const t=v.resolve(e);if(t.length<=2)return e;if(t.charCodeAt(0)===h){if(t.charCodeAt(1)===h){const e=t.charCodeAt(2);if(63!==e&&e!==l)return`\\\\?\\UNC\\${t.slice(2)}`}}else if(b(t.charCodeAt(0))&&t.charCodeAt(1)===u&&t.charCodeAt(2)===h)return`\\\\?\\${t}`;return e},dirname(e){g(e,"path");const t=e.length;if(0===t)return".";let n=-1,r=0;const i=e.charCodeAt(0);if(1===t)return m(i)?e:".";if(m(i)){if(n=r=1,m(e.charCodeAt(1))){let i=2,s=i;for(;i2&&m(e.charCodeAt(2))?3:2,r=n);let s=-1,o=!0;for(let a=t-1;a>=r;--a)if(m(e.charCodeAt(a))){if(!o){s=a;break}}else o=!1;if(-1===s){if(-1===n)return".";s=n}return e.slice(0,s)},basename(e,t){void 0!==t&&g(t,"suffix"),g(e,"path");let n,r=0,i=-1,s=!0;if(e.length>=2&&b(e.charCodeAt(0))&&e.charCodeAt(1)===u&&(r=2),void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let o=t.length-1,a=-1;for(n=e.length-1;n>=r;--n){const l=e.charCodeAt(n);if(m(l)){if(!s){r=n+1;break}}else-1===a&&(s=!1,a=n+1),o>=0&&(l===t.charCodeAt(o)?-1===--o&&(i=n):(o=-1,i=a))}return r===i?i=a:-1===i&&(i=e.length),e.slice(r,i)}for(n=e.length-1;n>=r;--n)if(m(e.charCodeAt(n))){if(!s){r=n+1;break}}else-1===i&&(s=!1,i=n+1);return-1===i?"":e.slice(r,i)},extname(e){g(e,"path");let t=0,n=-1,r=0,i=-1,s=!0,o=0;e.length>=2&&e.charCodeAt(1)===u&&b(e.charCodeAt(0))&&(t=r=2);for(let a=e.length-1;a>=t;--a){const t=e.charCodeAt(a);if(m(t)){if(!s){r=a+1;break}}else-1===i&&(s=!1,i=a+1),t===l?-1===n?n=a:1!==o&&(o=1):-1!==n&&(o=-1)}return-1===n||-1===i||0===o||1===o&&n===i-1&&n===r+1?"":e.slice(n,i)},format:k.bind(null,"\\"),parse(e){g(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const n=e.length;let r=0,i=e.charCodeAt(0);if(1===n)return m(i)?(t.root=t.dir=e,t):(t.base=t.name=e,t);if(m(i)){if(r=1,m(e.charCodeAt(1))){let t=2,i=t;for(;t0&&(t.root=e.slice(0,r));let s=-1,o=r,a=-1,c=!0,h=e.length-1,d=0;for(;h>=r;--h)if(i=e.charCodeAt(h),m(i)){if(!c){o=h+1;break}}else-1===a&&(c=!1,a=h+1),i===l?-1===s?s=h:1!==d&&(d=1):-1!==s&&(d=-1);return-1!==a&&(-1===s||0===d||1===d&&s===a-1&&s===o+1?t.base=t.name=e.slice(o,a):(t.name=e.slice(o,s),t.base=e.slice(o,a),t.ext=e.slice(s,a))),t.dir=o>0&&o!==r?e.slice(0,o-1):t.root,t},sep:"\\",delimiter:";",win32:null,posix:null},C=(()=>{if(f){const e=/\\/g;return()=>{const t=o().replace(e,"/");return t.slice(t.indexOf("/"))}}return()=>o()})(),y={resolve(...e){let t="",n=!1;for(let r=e.length-1;r>=-1&&!n;r--){const i=r>=0?e[r]:C();g(i,`paths[${r}]`),0!==i.length&&(t=`${i}/${t}`,n=i.charCodeAt(0)===c)}return t=_(t,!n,"/",p),n?`/${t}`:t.length>0?t:"."},normalize(e){if(g(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===c,n=e.charCodeAt(e.length-1)===c;return 0===(e=_(e,!t,"/",p)).length?t?"/":n?"./":".":(n&&(e+="/"),t?`/${e}`:e)},isAbsolute:e=>(g(e,"path"),e.length>0&&e.charCodeAt(0)===c),join(...e){if(0===e.length)return".";let t;for(let n=0;n0&&(void 0===t?t=r:t+=`/${r}`)}return void 0===t?".":y.normalize(t)},relative(e,t){if(g(e,"from"),g(t,"to"),e===t)return"";if((e=y.resolve(e))===(t=y.resolve(t)))return"";const n=e.length,r=n-1,i=t.length-1,s=rs){if(t.charCodeAt(1+a)===c)return t.slice(1+a+1);if(0===a)return t.slice(1+a)}else r>s&&(e.charCodeAt(1+a)===c?o=a:0===a&&(o=0));let l="";for(a=1+o+1;a<=n;++a)a!==n&&e.charCodeAt(a)!==c||(l+=0===l.length?"..":"/..");return`${l}${t.slice(1+o)}`},toNamespacedPath:e=>e,dirname(e){if(g(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===c;let n=-1,r=!0;for(let i=e.length-1;i>=1;--i)if(e.charCodeAt(i)===c){if(!r){n=i;break}}else r=!1;return-1===n?t?"/":".":t&&1===n?"//":e.slice(0,n)},basename(e,t){void 0!==t&&g(t,"ext"),g(e,"path");let n,r=0,i=-1,s=!0;if(void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let o=t.length-1,a=-1;for(n=e.length-1;n>=0;--n){const l=e.charCodeAt(n);if(l===c){if(!s){r=n+1;break}}else-1===a&&(s=!1,a=n+1),o>=0&&(l===t.charCodeAt(o)?-1===--o&&(i=n):(o=-1,i=a))}return r===i?i=a:-1===i&&(i=e.length),e.slice(r,i)}for(n=e.length-1;n>=0;--n)if(e.charCodeAt(n)===c){if(!s){r=n+1;break}}else-1===i&&(s=!1,i=n+1);return-1===i?"":e.slice(r,i)},extname(e){g(e,"path");let t=-1,n=0,r=-1,i=!0,s=0;for(let o=e.length-1;o>=0;--o){const a=e.charCodeAt(o);if(a!==c)-1===r&&(i=!1,r=o+1),a===l?-1===t?t=o:1!==s&&(s=1):-1!==t&&(s=-1);else if(!i){n=o+1;break}}return-1===t||-1===r||0===s||1===s&&t===r-1&&t===n+1?"":e.slice(t,r)},format:k.bind(null,"/"),parse(e){g(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const n=e.charCodeAt(0)===c;let r;n?(t.root="/",r=1):r=0;let i=-1,s=0,o=-1,a=!0,h=e.length-1,u=0;for(;h>=r;--h){const t=e.charCodeAt(h);if(t!==c)-1===o&&(a=!1,o=h+1),t===l?-1===i?i=h:1!==u&&(u=1):-1!==i&&(u=-1);else if(!a){s=h+1;break}}if(-1!==o){const r=0===s&&n?1:s;-1===i||0===u||1===u&&i===o-1&&i===s+1?t.base=t.name=e.slice(r,o):(t.name=e.slice(r,i),t.base=e.slice(r,o),t.ext=e.slice(i,o))}return s>0?t.dir=e.slice(0,s-1):n&&(t.dir="/"),t},sep:"/",delimiter:":",win32:null,posix:null};y.win32=v.win32=v,y.posix=v.posix=y;const L=f?v.normalize:y.normalize,w=f?v.join:y.join,S=f?v.resolve:y.resolve,x=f?v.relative:y.relative,E=f?v.dirname:y.dirname,N=f?v.basename:y.basename,T=f?v.extname:y.extname,A=f?v.sep:y.sep},8868:(e,t,n)=>{"use strict";n.r(t)},8925:(e,t,n)=>{"use strict";n.d(t,{w:()=>i});class r{static{this.Undefined=new r(void 0)}constructor(e){this.element=e,this.next=r.Undefined,this.prev=r.Undefined}}class i{constructor(){this._first=r.Undefined,this._last=r.Undefined,this._size=0}get size(){return this._size}isEmpty(){return this._first===r.Undefined}clear(){let e=this._first;for(;e!==r.Undefined;){const t=e.next;e.prev=r.Undefined,e.next=r.Undefined,e=t}this._first=r.Undefined,this._last=r.Undefined,this._size=0}unshift(e){return this._insert(e,!1)}push(e){return this._insert(e,!0)}_insert(e,t){const n=new r(e);if(this._first===r.Undefined)this._first=n,this._last=n;else if(t){const e=this._last;this._last=n,n.prev=e,e.next=n}else{const e=this._first;this._first=n,n.next=e,e.prev=n}this._size+=1;let i=!1;return()=>{i||(i=!0,this._remove(n))}}shift(){if(this._first!==r.Undefined){const e=this._first.element;return this._remove(this._first),e}}pop(){if(this._last!==r.Undefined){const e=this._last.element;return this._remove(this._last),e}}_remove(e){if(e.prev!==r.Undefined&&e.next!==r.Undefined){const t=e.prev;t.next=e.next,e.next.prev=t}else e.prev===r.Undefined&&e.next===r.Undefined?(this._first=r.Undefined,this._last=r.Undefined):e.next===r.Undefined?(this._last=this._last.prev,this._last.next=r.Undefined):e.prev===r.Undefined&&(this._first=this._first.next,this._first.prev=r.Undefined);this._size-=1}*[Symbol.iterator](){let e=this._first;for(;e!==r.Undefined;)yield e.element,e=e.next}}},8938:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITextModelService:()=>r});const r=(0,n(3591).u1)("textModelService")},9100:(e,t,n)=>{"use strict";n.r(t),n.d(t,{ITreeViewsDnDService:()=>o});var r=n(4621),i=n(3591),s=n(6723);const o=(0,i.u1)("treeViewsDndService");(0,r.v)(o,s.TreeViewsDnDService,1)},9204:(e,t,n)=>{var r={"./editorBaseApi":[4272],"./editorBaseApi.js":[4272],"./editorSimpleWorker":[5196],"./editorSimpleWorker.js":[5196],"./editorWorker":[920,792],"./editorWorker.js":[920,792],"./editorWorkerHost":[718],"./editorWorkerHost.js":[718],"./findSectionHeaders":[6691],"./findSectionHeaders.js":[6691],"./getIconClasses":[5628,792],"./getIconClasses.js":[5628,792],"./languageFeatureDebounce":[8709,792],"./languageFeatureDebounce.js":[8709,792],"./languageFeatures":[6942,792],"./languageFeatures.js":[6942,792],"./languageFeaturesService":[2661,792],"./languageFeaturesService.js":[2661,792],"./languageService":[7596,792],"./languageService.js":[7596,792],"./languagesAssociations":[9908,792],"./languagesAssociations.js":[9908,792],"./languagesRegistry":[9259,792],"./languagesRegistry.js":[9259,792],"./markerDecorations":[7550,792],"./markerDecorations.js":[7550,792],"./markerDecorationsService":[448,792],"./markerDecorationsService.js":[448,792],"./model":[3750,792],"./model.js":[3750,792],"./modelService":[1773,792],"./modelService.js":[1773,792],"./resolverService":[8938,792],"./resolverService.js":[8938,792],"./semanticTokensDto":[8232,792],"./semanticTokensDto.js":[8232,792],"./semanticTokensProviderStyling":[5538,792],"./semanticTokensProviderStyling.js":[5538,792],"./semanticTokensStyling":[4243,792],"./semanticTokensStyling.js":[4243,792],"./semanticTokensStylingService":[7004,792],"./semanticTokensStylingService.js":[7004,792],"./textModelSync/textModelSync.impl":[796],"./textModelSync/textModelSync.impl.js":[796],"./textModelSync/textModelSync.protocol":[8868,792],"./textModelSync/textModelSync.protocol.js":[8868,792],"./textResourceConfiguration":[360,792],"./textResourceConfiguration.js":[360,792],"./treeSitterParserService":[4432,792],"./treeSitterParserService.js":[4432,792],"./treeViewsDnd":[6723,792],"./treeViewsDnd.js":[6723,792],"./treeViewsDndService":[9100,792],"./treeViewsDndService.js":[9100,792],"./unicodeTextModelHighlighter":[4855],"./unicodeTextModelHighlighter.js":[4855],"monaco-editor/esm/vs/editor/common/services/editorBaseApi":[4272],"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":[4272],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":[5196],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":[5196],"monaco-editor/esm/vs/editor/common/services/editorWorker":[920,792],"monaco-editor/esm/vs/editor/common/services/editorWorker.js":[920,792],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":[718],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":[718],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":[6691],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":[6691],"monaco-editor/esm/vs/editor/common/services/getIconClasses":[5628,792],"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":[5628,792],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":[8709,792],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":[8709,792],"monaco-editor/esm/vs/editor/common/services/languageFeatures":[6942,792],"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":[6942,792],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":[2661,792],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":[2661,792],"monaco-editor/esm/vs/editor/common/services/languageService":[7596,792],"monaco-editor/esm/vs/editor/common/services/languageService.js":[7596,792],"monaco-editor/esm/vs/editor/common/services/languagesAssociations":[9908,792],"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":[9908,792],"monaco-editor/esm/vs/editor/common/services/languagesRegistry":[9259,792],"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":[9259,792],"monaco-editor/esm/vs/editor/common/services/markerDecorations":[7550,792],"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":[7550,792],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":[448,792],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":[448,792],"monaco-editor/esm/vs/editor/common/services/model":[3750,792],"monaco-editor/esm/vs/editor/common/services/model.js":[3750,792],"monaco-editor/esm/vs/editor/common/services/modelService":[1773,792],"monaco-editor/esm/vs/editor/common/services/modelService.js":[1773,792],"monaco-editor/esm/vs/editor/common/services/resolverService":[8938,792],"monaco-editor/esm/vs/editor/common/services/resolverService.js":[8938,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":[8232,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":[8232,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":[5538,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":[5538,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":[4243,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":[4243,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":[7004,792],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":[7004,792],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":[796],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":[796],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":[8868,792],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":[8868,792],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":[360,792],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":[360,792],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":[4432,792],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":[4432,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":[6723,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":[6723,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":[9100,792],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":[9100,792],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":[4855],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":[4855]};function i(e){if(!n.o(r,e))return Promise.resolve().then((()=>{var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}));var t=r[e],i=t[0];return Promise.all(t.slice(1).map(n.e)).then((()=>n(i)))}i.keys=()=>Object.keys(r),i.id=9204,e.exports=i},9259:(e,t,n)=>{"use strict";n.r(t),n.d(t,{LanguageIdCodec:()=>d,LanguagesRegistry:()=>g});var r=n(1234),i=n(1484),s=n(1508),o=n(9908),a=n(3941),l=n(1646),c=n(6359);const h=Object.prototype.hasOwnProperty,u="vs.editor.nullLanguage";class d{constructor(){this._languageIdToLanguage=[],this._languageToLanguageId=new Map,this._register(u,0),this._register(a.vH,1),this._nextLanguageId=2}_register(e,t){this._languageIdToLanguage[t]=e,this._languageToLanguageId.set(e,t)}register(e){if(this._languageToLanguageId.has(e))return;const t=this._nextLanguageId++;this._register(e,t)}encodeLanguageId(e){return this._languageToLanguageId.get(e)||0}decodeLanguageId(e){return this._languageIdToLanguage[e]||u}}class g extends i.jG{static{this.instanceCount=0}constructor(e=!0,t=!1){super(),this._onDidChange=this._register(new r.vl),this.onDidChange=this._onDidChange.event,g.instanceCount++,this._warnOnOverwrite=t,this.languageIdCodec=new d,this._dynamicLanguages=[],this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},e&&(this._initializeFromRegistry(),this._register(a.W6.onDidChangeLanguages((e=>{this._initializeFromRegistry()}))))}dispose(){g.instanceCount--,super.dispose()}_initializeFromRegistry(){this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},(0,o.clearPlatformLanguageAssociations)();const e=[].concat(a.W6.getLanguages()).concat(this._dynamicLanguages);this._registerLanguages(e)}_registerLanguages(e){for(const t of e)this._registerLanguage(t);this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},Object.keys(this._languages).forEach((e=>{const t=this._languages[e];t.name&&(this._nameMap[t.name]=t.identifier),t.aliases.forEach((e=>{this._lowercaseNameMap[e.toLowerCase()]=t.identifier})),t.mimetypes.forEach((e=>{this._mimeTypesMap[e]=t.identifier}))})),c.O.as(l.Fd.Configuration).registerOverrideIdentifiers(this.getRegisteredLanguageIds()),this._onDidChange.fire()}_registerLanguage(e){const t=e.id;let n;h.call(this._languages,t)?n=this._languages[t]:(this.languageIdCodec.register(t),n={identifier:t,name:null,mimetypes:[],aliases:[],extensions:[],filenames:[],configurationFiles:[],icons:[]},this._languages[t]=n),this._mergeLanguage(n,e)}_mergeLanguage(e,t){const n=t.id;let r=null;if(Array.isArray(t.mimetypes)&&t.mimetypes.length>0&&(e.mimetypes.push(...t.mimetypes),r=t.mimetypes[0]),r||(r=`text/x-${n}`,e.mimetypes.push(r)),Array.isArray(t.extensions)){t.configuration?e.extensions=t.extensions.concat(e.extensions):e.extensions=e.extensions.concat(t.extensions);for(const e of t.extensions)(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,extension:e},this._warnOnOverwrite)}if(Array.isArray(t.filenames))for(const s of t.filenames)(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,filename:s},this._warnOnOverwrite),e.filenames.push(s);if(Array.isArray(t.filenamePatterns))for(const s of t.filenamePatterns)(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,filepattern:s},this._warnOnOverwrite);if("string"===typeof t.firstLine&&t.firstLine.length>0){let e=t.firstLine;"^"!==e.charAt(0)&&(e="^"+e);try{const t=new RegExp(e);(0,s.eY)(t)||(0,o.registerPlatformLanguageAssociation)({id:n,mime:r,firstline:t},this._warnOnOverwrite)}catch(l){console.warn(`[${t.id}]: Invalid regular expression \`${e}\`: `,l)}}e.aliases.push(n);let i=null;if("undefined"!==typeof t.aliases&&Array.isArray(t.aliases)&&(i=0===t.aliases.length?[null]:t.aliases),null!==i)for(const s of i)s&&0!==s.length&&e.aliases.push(s);const a=null!==i&&i.length>0;if(a&&null===i[0]);else{const t=(a?i[0]:null)||n;!a&&e.name||(e.name=t)}t.configuration&&e.configurationFiles.push(t.configuration),t.icon&&e.icons.push(t.icon)}isRegisteredLanguageId(e){return!!e&&h.call(this._languages,e)}getRegisteredLanguageIds(){return Object.keys(this._languages)}getLanguageIdByLanguageName(e){const t=e.toLowerCase();return h.call(this._lowercaseNameMap,t)?this._lowercaseNameMap[t]:null}getLanguageIdByMimeType(e){return e&&h.call(this._mimeTypesMap,e)?this._mimeTypesMap[e]:null}guessLanguageIdByFilepathOrFirstLine(e,t){return e||t?(0,o.getLanguageIds)(e,t):[]}}},9326:(e,t,n)=>{"use strict";n.d(t,{TH:()=>o,Zn:()=>l,_1:()=>c,kb:()=>a});var r=n(8821),i=(n(8067),n(1508));function s(e){return 47===e||92===e}function o(e){return e.replace(/[\\/]/g,r.SA.sep)}function a(e){return-1===e.indexOf("/")&&(e=o(e)),/^[a-zA-Z]:(\/|$)/.test(e)&&(e="/"+e),e}function l(e,t=r.SA.sep){if(!e)return"";const n=e.length,i=e.charCodeAt(0);if(s(i)){if(s(e.charCodeAt(1))&&!s(e.charCodeAt(2))){let r=3;const i=r;for(;re.length)return!1;if(n){if(!(0,i.ns)(e,t))return!1;if(t.length===e.length)return!0;let n=t.length;return t.charAt(t.length-1)===s&&n--,e.charAt(n)===s}return t.charAt(t.length-1)!==s&&(t+=s),0===e.indexOf(t)}function h(e){return e>=65&&e<=90||e>=97&&e<=122}},9400:(e,t,n)=>{"use strict";n.d(t,{I:()=>b,r:()=>u});var r=n(8821),i=n(8067);const s=/^\w[\w\d+.-]*$/,o=/^\//,a=/^\/\//;const l="",c="/",h=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/;class u{static isUri(e){return e instanceof u||!!e&&("string"===typeof e.authority&&"string"===typeof e.fragment&&"string"===typeof e.path&&"string"===typeof e.query&&"string"===typeof e.scheme&&"string"===typeof e.fsPath&&"function"===typeof e.with&&"function"===typeof e.toString)}constructor(e,t,n,r,i,h=!1){"object"===typeof e?(this.scheme=e.scheme||l,this.authority=e.authority||l,this.path=e.path||l,this.query=e.query||l,this.fragment=e.fragment||l):(this.scheme=function(e,t){return e||t?e:"file"}(e,h),this.authority=t||l,this.path=function(e,t){switch(e){case"https":case"http":case"file":t?t[0]!==c&&(t=c+t):t=c}return t}(this.scheme,n||l),this.query=r||l,this.fragment=i||l,function(e,t){if(!e.scheme&&t)throw new Error(`[UriError]: Scheme is missing: {scheme: "", authority: "${e.authority}", path: "${e.path}", query: "${e.query}", fragment: "${e.fragment}"}`);if(e.scheme&&!s.test(e.scheme))throw new Error("[UriError]: Scheme contains illegal characters.");if(e.path)if(e.authority){if(!o.test(e.path))throw new Error('[UriError]: If a URI contains an authority component, then the path component must either be empty or begin with a slash ("/") character')}else if(a.test(e.path))throw new Error('[UriError]: If a URI does not contain an authority component, then the path cannot begin with two slash characters ("//")')}(this,h))}get fsPath(){return b(this,!1)}with(e){if(!e)return this;let{scheme:t,authority:n,path:r,query:i,fragment:s}=e;return void 0===t?t=this.scheme:null===t&&(t=l),void 0===n?n=this.authority:null===n&&(n=l),void 0===r?r=this.path:null===r&&(r=l),void 0===i?i=this.query:null===i&&(i=l),void 0===s?s=this.fragment:null===s&&(s=l),t===this.scheme&&n===this.authority&&r===this.path&&i===this.query&&s===this.fragment?this:new g(t,n,r,i,s)}static parse(e,t=!1){const n=h.exec(e);return n?new g(n[2]||l,C(n[4]||l),C(n[5]||l),C(n[7]||l),C(n[9]||l),t):new g(l,l,l,l,l)}static file(e){let t=l;if(i.uF&&(e=e.replace(/\\/g,c)),e[0]===c&&e[1]===c){const n=e.indexOf(c,2);-1===n?(t=e.substring(2),e=c):(t=e.substring(2,n),e=e.substring(n)||c)}return new g("file",t,e,l,l)}static from(e,t){return new g(e.scheme,e.authority,e.path,e.query,e.fragment,t)}static joinPath(e,...t){if(!e.path)throw new Error("[UriError]: cannot call joinPath on URI without path");let n;return n=i.uF&&"file"===e.scheme?u.file(r.IN.join(b(e,!0),...t)).path:r.SA.join(e.path,...t),e.with({path:n})}toString(e=!1){return _(this,e)}toJSON(){return this}static revive(e){if(e){if(e instanceof u)return e;{const t=new g(e);return t._formatted=e.external??null,t._fsPath=e._sep===d?e.fsPath??null:null,t}}return e}}const d=i.uF?1:void 0;class g extends u{constructor(){super(...arguments),this._formatted=null,this._fsPath=null}get fsPath(){return this._fsPath||(this._fsPath=b(this,!1)),this._fsPath}toString(e=!1){return e?_(this,!0):(this._formatted||(this._formatted=_(this,!1)),this._formatted)}toJSON(){const e={$mid:1};return this._fsPath&&(e.fsPath=this._fsPath,e._sep=d),this._formatted&&(e.external=this._formatted),this.path&&(e.path=this.path),this.scheme&&(e.scheme=this.scheme),this.authority&&(e.authority=this.authority),this.query&&(e.query=this.query),this.fragment&&(e.fragment=this.fragment),e}}const f={58:"%3A",47:"%2F",63:"%3F",35:"%23",91:"%5B",93:"%5D",64:"%40",33:"%21",36:"%24",38:"%26",39:"%27",40:"%28",41:"%29",42:"%2A",43:"%2B",44:"%2C",59:"%3B",61:"%3D",32:"%20"};function m(e,t,n){let r,i=-1;for(let s=0;s=97&&o<=122||o>=65&&o<=90||o>=48&&o<=57||45===o||46===o||95===o||126===o||t&&47===o||n&&91===o||n&&93===o||n&&58===o)-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),void 0!==r&&(r+=e.charAt(s));else{void 0===r&&(r=e.substr(0,s));const t=f[o];void 0!==t?(-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),r+=t):-1===i&&(i=s)}}return-1!==i&&(r+=encodeURIComponent(e.substring(i))),void 0!==r?r:e}function p(e){let t;for(let n=0;n1&&"file"===e.scheme?`//${e.authority}${e.path}`:47===e.path.charCodeAt(0)&&(e.path.charCodeAt(1)>=65&&e.path.charCodeAt(1)<=90||e.path.charCodeAt(1)>=97&&e.path.charCodeAt(1)<=122)&&58===e.path.charCodeAt(2)?t?e.path.substr(1):e.path[1].toLowerCase()+e.path.substr(2):e.path,i.uF&&(n=n.replace(/\//g,"\\")),n}function _(e,t){const n=t?p:m;let r="",{scheme:i,authority:s,path:o,query:a,fragment:l}=e;if(i&&(r+=i,r+=":"),(s||"file"===i)&&(r+=c,r+=c),s){let e=s.indexOf("@");if(-1!==e){const t=s.substr(0,e);s=s.substr(e+1),e=t.lastIndexOf(":"),-1===e?r+=n(t,!1,!1):(r+=n(t.substr(0,e),!1,!1),r+=":",r+=n(t.substr(e+1),!1,!0)),r+="@"}s=s.toLowerCase(),e=s.lastIndexOf(":"),-1===e?r+=n(s,!1,!0):(r+=n(s.substr(0,e),!1,!0),r+=s.substr(e))}if(o){if(o.length>=3&&47===o.charCodeAt(0)&&58===o.charCodeAt(2)){const e=o.charCodeAt(1);e>=65&&e<=90&&(o=`/${String.fromCharCode(e+32)}:${o.substr(3)}`)}else if(o.length>=2&&58===o.charCodeAt(1)){const e=o.charCodeAt(0);e>=65&&e<=90&&(o=`${String.fromCharCode(e+32)}:${o.substr(2)}`)}r+=n(o,!0,!1)}return a&&(r+="?",r+=n(a,!1,!1)),l&&(r+="#",r+=t?l:m(l,!1,!1)),r}function k(e){try{return decodeURIComponent(e)}catch{return e.length>3?e.substr(0,3)+k(e.substr(3)):e}}const v=/(%[0-9A-Za-z][0-9A-Za-z])+/g;function C(e){return e.match(v)?e.replace(v,(e=>k(e))):e}},9403:(e,t,n)=>{"use strict";n.d(t,{B6:()=>m,P8:()=>d});var r=n(9326),i=n(6456),s=n(8821),o=n(8067),a=n(1508),l=n(9400);function c(e){return(0,l.I)(e,!0)}class h{constructor(e){this._ignorePathCasing=e}compare(e,t,n=!1){return e===t?0:(0,a.UD)(this.getComparisonKey(e,n),this.getComparisonKey(t,n))}isEqual(e,t,n=!1){return e===t||!(!e||!t)&&this.getComparisonKey(e,n)===this.getComparisonKey(t,n)}getComparisonKey(e,t=!1){return e.with({path:this._ignorePathCasing(e)?e.path.toLowerCase():void 0,fragment:t?null:void 0}).toString()}isEqualOrParent(e,t,n=!1){if(e.scheme===t.scheme){if(e.scheme===i.ny.file)return r._1(c(e),c(t),this._ignorePathCasing(e))&&e.query===t.query&&(n||e.fragment===t.fragment);if(g(e.authority,t.authority))return r._1(e.path,t.path,this._ignorePathCasing(e),"/")&&e.query===t.query&&(n||e.fragment===t.fragment)}return!1}joinPath(e,...t){return l.r.joinPath(e,...t)}basenameOrAuthority(e){return d(e)||e.authority}basename(e){return s.SA.basename(e.path)}extname(e){return s.SA.extname(e.path)}dirname(e){if(0===e.path.length)return e;let t;return e.scheme===i.ny.file?t=l.r.file(s.pD(c(e))).path:(t=s.SA.dirname(e.path),e.authority&&t.length&&47!==t.charCodeAt(0)&&(console.error(`dirname("${e.toString})) resulted in a relative path`),t="/")),e.with({path:t})}normalizePath(e){if(!e.path.length)return e;let t;return t=e.scheme===i.ny.file?l.r.file(s.S8(c(e))).path:s.SA.normalize(e.path),e.with({path:t})}relativePath(e,t){if(e.scheme!==t.scheme||!g(e.authority,t.authority))return;if(e.scheme===i.ny.file){const n=s.V8(c(e),c(t));return o.uF?r.TH(n):n}let n=e.path||"/";const a=t.path||"/";if(this._ignorePathCasing(e)){let e=0;for(const t=Math.min(n.length,a.length);er.Zn(n).length&&n[n.length-1]===t}{const t=e.path;return t.length>1&&47===t.charCodeAt(t.length-1)&&!/^[a-zA-Z]:(\/$|\\$)/.test(e.fsPath)}}removeTrailingPathSeparator(e,t=s.Vn){return f(e,t)?e.with({path:e.path.substr(0,e.path.length-1)}):e}addTrailingPathSeparator(e,t=s.Vn){let n=!1;if(e.scheme===i.ny.file){const i=c(e);n=void 0!==i&&i.length===r.Zn(i).length&&i[i.length-1]===t}else{t="/";const r=e.path;n=1===r.length&&47===r.charCodeAt(r.length-1)}return n||f(e,t)?e:e.with({path:e.path+"/"})}}const u=new h((()=>!1)),d=(new h((e=>e.scheme!==i.ny.file||!o.j9)),new h((e=>!0)),u.isEqual.bind(u),u.isEqualOrParent.bind(u),u.getComparisonKey.bind(u),u.basenameOrAuthority.bind(u),u.basename.bind(u)),g=(u.extname.bind(u),u.dirname.bind(u),u.joinPath.bind(u),u.normalizePath.bind(u),u.relativePath.bind(u),u.resolvePath.bind(u),u.isAbsolutePath.bind(u),u.isEqualAuthority.bind(u)),f=u.hasTrailingPathSeparator.bind(u);u.removeTrailingPathSeparator.bind(u),u.addTrailingPathSeparator.bind(u);var m;!function(e){e.META_DATA_LABEL="label",e.META_DATA_DESCRIPTION="description",e.META_DATA_SIZE="size",e.META_DATA_MIME="mime",e.parseMetaData=function(t){const n=new Map;t.path.substring(t.path.indexOf(";")+1,t.path.lastIndexOf(";")).split(";").forEach((e=>{const[t,r]=e.split(":");t&&r&&n.set(t,r)}));const r=t.path.substring(0,t.path.indexOf(";"));return r&&n.set(e.META_DATA_MIME,r),n}}(m||(m={}))},9493:(e,t,n)=>{"use strict";n.d(t,{W:()=>o});var r=n(631);const i=Object.create(null);function s(e,t){if((0,r.Kg)(t)){const n=i[t];if(void 0===n)throw new Error(`${e} references an unknown codicon: ${t}`);t=n}return i[e]=t,{id:e}}const o={...{add:s("add",6e4),plus:s("plus",6e4),gistNew:s("gist-new",6e4),repoCreate:s("repo-create",6e4),lightbulb:s("lightbulb",60001),lightBulb:s("light-bulb",60001),repo:s("repo",60002),repoDelete:s("repo-delete",60002),gistFork:s("gist-fork",60003),repoForked:s("repo-forked",60003),gitPullRequest:s("git-pull-request",60004),gitPullRequestAbandoned:s("git-pull-request-abandoned",60004),recordKeys:s("record-keys",60005),keyboard:s("keyboard",60005),tag:s("tag",60006),gitPullRequestLabel:s("git-pull-request-label",60006),tagAdd:s("tag-add",60006),tagRemove:s("tag-remove",60006),person:s("person",60007),personFollow:s("person-follow",60007),personOutline:s("person-outline",60007),personFilled:s("person-filled",60007),gitBranch:s("git-branch",60008),gitBranchCreate:s("git-branch-create",60008),gitBranchDelete:s("git-branch-delete",60008),sourceControl:s("source-control",60008),mirror:s("mirror",60009),mirrorPublic:s("mirror-public",60009),star:s("star",60010),starAdd:s("star-add",60010),starDelete:s("star-delete",60010),starEmpty:s("star-empty",60010),comment:s("comment",60011),commentAdd:s("comment-add",60011),alert:s("alert",60012),warning:s("warning",60012),search:s("search",60013),searchSave:s("search-save",60013),logOut:s("log-out",60014),signOut:s("sign-out",60014),logIn:s("log-in",60015),signIn:s("sign-in",60015),eye:s("eye",60016),eyeUnwatch:s("eye-unwatch",60016),eyeWatch:s("eye-watch",60016),circleFilled:s("circle-filled",60017),primitiveDot:s("primitive-dot",60017),closeDirty:s("close-dirty",60017),debugBreakpoint:s("debug-breakpoint",60017),debugBreakpointDisabled:s("debug-breakpoint-disabled",60017),debugHint:s("debug-hint",60017),terminalDecorationSuccess:s("terminal-decoration-success",60017),primitiveSquare:s("primitive-square",60018),edit:s("edit",60019),pencil:s("pencil",60019),info:s("info",60020),issueOpened:s("issue-opened",60020),gistPrivate:s("gist-private",60021),gitForkPrivate:s("git-fork-private",60021),lock:s("lock",60021),mirrorPrivate:s("mirror-private",60021),close:s("close",60022),removeClose:s("remove-close",60022),x:s("x",60022),repoSync:s("repo-sync",60023),sync:s("sync",60023),clone:s("clone",60024),desktopDownload:s("desktop-download",60024),beaker:s("beaker",60025),microscope:s("microscope",60025),vm:s("vm",60026),deviceDesktop:s("device-desktop",60026),file:s("file",60027),fileText:s("file-text",60027),more:s("more",60028),ellipsis:s("ellipsis",60028),kebabHorizontal:s("kebab-horizontal",60028),mailReply:s("mail-reply",60029),reply:s("reply",60029),organization:s("organization",60030),organizationFilled:s("organization-filled",60030),organizationOutline:s("organization-outline",60030),newFile:s("new-file",60031),fileAdd:s("file-add",60031),newFolder:s("new-folder",60032),fileDirectoryCreate:s("file-directory-create",60032),trash:s("trash",60033),trashcan:s("trashcan",60033),history:s("history",60034),clock:s("clock",60034),folder:s("folder",60035),fileDirectory:s("file-directory",60035),symbolFolder:s("symbol-folder",60035),logoGithub:s("logo-github",60036),markGithub:s("mark-github",60036),github:s("github",60036),terminal:s("terminal",60037),console:s("console",60037),repl:s("repl",60037),zap:s("zap",60038),symbolEvent:s("symbol-event",60038),error:s("error",60039),stop:s("stop",60039),variable:s("variable",60040),symbolVariable:s("symbol-variable",60040),array:s("array",60042),symbolArray:s("symbol-array",60042),symbolModule:s("symbol-module",60043),symbolPackage:s("symbol-package",60043),symbolNamespace:s("symbol-namespace",60043),symbolObject:s("symbol-object",60043),symbolMethod:s("symbol-method",60044),symbolFunction:s("symbol-function",60044),symbolConstructor:s("symbol-constructor",60044),symbolBoolean:s("symbol-boolean",60047),symbolNull:s("symbol-null",60047),symbolNumeric:s("symbol-numeric",60048),symbolNumber:s("symbol-number",60048),symbolStructure:s("symbol-structure",60049),symbolStruct:s("symbol-struct",60049),symbolParameter:s("symbol-parameter",60050),symbolTypeParameter:s("symbol-type-parameter",60050),symbolKey:s("symbol-key",60051),symbolText:s("symbol-text",60051),symbolReference:s("symbol-reference",60052),goToFile:s("go-to-file",60052),symbolEnum:s("symbol-enum",60053),symbolValue:s("symbol-value",60053),symbolRuler:s("symbol-ruler",60054),symbolUnit:s("symbol-unit",60054),activateBreakpoints:s("activate-breakpoints",60055),archive:s("archive",60056),arrowBoth:s("arrow-both",60057),arrowDown:s("arrow-down",60058),arrowLeft:s("arrow-left",60059),arrowRight:s("arrow-right",60060),arrowSmallDown:s("arrow-small-down",60061),arrowSmallLeft:s("arrow-small-left",60062),arrowSmallRight:s("arrow-small-right",60063),arrowSmallUp:s("arrow-small-up",60064),arrowUp:s("arrow-up",60065),bell:s("bell",60066),bold:s("bold",60067),book:s("book",60068),bookmark:s("bookmark",60069),debugBreakpointConditionalUnverified:s("debug-breakpoint-conditional-unverified",60070),debugBreakpointConditional:s("debug-breakpoint-conditional",60071),debugBreakpointConditionalDisabled:s("debug-breakpoint-conditional-disabled",60071),debugBreakpointDataUnverified:s("debug-breakpoint-data-unverified",60072),debugBreakpointData:s("debug-breakpoint-data",60073),debugBreakpointDataDisabled:s("debug-breakpoint-data-disabled",60073),debugBreakpointLogUnverified:s("debug-breakpoint-log-unverified",60074),debugBreakpointLog:s("debug-breakpoint-log",60075),debugBreakpointLogDisabled:s("debug-breakpoint-log-disabled",60075),briefcase:s("briefcase",60076),broadcast:s("broadcast",60077),browser:s("browser",60078),bug:s("bug",60079),calendar:s("calendar",60080),caseSensitive:s("case-sensitive",60081),check:s("check",60082),checklist:s("checklist",60083),chevronDown:s("chevron-down",60084),chevronLeft:s("chevron-left",60085),chevronRight:s("chevron-right",60086),chevronUp:s("chevron-up",60087),chromeClose:s("chrome-close",60088),chromeMaximize:s("chrome-maximize",60089),chromeMinimize:s("chrome-minimize",60090),chromeRestore:s("chrome-restore",60091),circleOutline:s("circle-outline",60092),circle:s("circle",60092),debugBreakpointUnverified:s("debug-breakpoint-unverified",60092),terminalDecorationIncomplete:s("terminal-decoration-incomplete",60092),circleSlash:s("circle-slash",60093),circuitBoard:s("circuit-board",60094),clearAll:s("clear-all",60095),clippy:s("clippy",60096),closeAll:s("close-all",60097),cloudDownload:s("cloud-download",60098),cloudUpload:s("cloud-upload",60099),code:s("code",60100),collapseAll:s("collapse-all",60101),colorMode:s("color-mode",60102),commentDiscussion:s("comment-discussion",60103),creditCard:s("credit-card",60105),dash:s("dash",60108),dashboard:s("dashboard",60109),database:s("database",60110),debugContinue:s("debug-continue",60111),debugDisconnect:s("debug-disconnect",60112),debugPause:s("debug-pause",60113),debugRestart:s("debug-restart",60114),debugStart:s("debug-start",60115),debugStepInto:s("debug-step-into",60116),debugStepOut:s("debug-step-out",60117),debugStepOver:s("debug-step-over",60118),debugStop:s("debug-stop",60119),debug:s("debug",60120),deviceCameraVideo:s("device-camera-video",60121),deviceCamera:s("device-camera",60122),deviceMobile:s("device-mobile",60123),diffAdded:s("diff-added",60124),diffIgnored:s("diff-ignored",60125),diffModified:s("diff-modified",60126),diffRemoved:s("diff-removed",60127),diffRenamed:s("diff-renamed",60128),diff:s("diff",60129),diffSidebyside:s("diff-sidebyside",60129),discard:s("discard",60130),editorLayout:s("editor-layout",60131),emptyWindow:s("empty-window",60132),exclude:s("exclude",60133),extensions:s("extensions",60134),eyeClosed:s("eye-closed",60135),fileBinary:s("file-binary",60136),fileCode:s("file-code",60137),fileMedia:s("file-media",60138),filePdf:s("file-pdf",60139),fileSubmodule:s("file-submodule",60140),fileSymlinkDirectory:s("file-symlink-directory",60141),fileSymlinkFile:s("file-symlink-file",60142),fileZip:s("file-zip",60143),files:s("files",60144),filter:s("filter",60145),flame:s("flame",60146),foldDown:s("fold-down",60147),foldUp:s("fold-up",60148),fold:s("fold",60149),folderActive:s("folder-active",60150),folderOpened:s("folder-opened",60151),gear:s("gear",60152),gift:s("gift",60153),gistSecret:s("gist-secret",60154),gist:s("gist",60155),gitCommit:s("git-commit",60156),gitCompare:s("git-compare",60157),compareChanges:s("compare-changes",60157),gitMerge:s("git-merge",60158),githubAction:s("github-action",60159),githubAlt:s("github-alt",60160),globe:s("globe",60161),grabber:s("grabber",60162),graph:s("graph",60163),gripper:s("gripper",60164),heart:s("heart",60165),home:s("home",60166),horizontalRule:s("horizontal-rule",60167),hubot:s("hubot",60168),inbox:s("inbox",60169),issueReopened:s("issue-reopened",60171),issues:s("issues",60172),italic:s("italic",60173),jersey:s("jersey",60174),json:s("json",60175),kebabVertical:s("kebab-vertical",60176),key:s("key",60177),law:s("law",60178),lightbulbAutofix:s("lightbulb-autofix",60179),linkExternal:s("link-external",60180),link:s("link",60181),listOrdered:s("list-ordered",60182),listUnordered:s("list-unordered",60183),liveShare:s("live-share",60184),loading:s("loading",60185),location:s("location",60186),mailRead:s("mail-read",60187),mail:s("mail",60188),markdown:s("markdown",60189),megaphone:s("megaphone",60190),mention:s("mention",60191),milestone:s("milestone",60192),gitPullRequestMilestone:s("git-pull-request-milestone",60192),mortarBoard:s("mortar-board",60193),move:s("move",60194),multipleWindows:s("multiple-windows",60195),mute:s("mute",60196),noNewline:s("no-newline",60197),note:s("note",60198),octoface:s("octoface",60199),openPreview:s("open-preview",60200),package:s("package",60201),paintcan:s("paintcan",60202),pin:s("pin",60203),play:s("play",60204),run:s("run",60204),plug:s("plug",60205),preserveCase:s("preserve-case",60206),preview:s("preview",60207),project:s("project",60208),pulse:s("pulse",60209),question:s("question",60210),quote:s("quote",60211),radioTower:s("radio-tower",60212),reactions:s("reactions",60213),references:s("references",60214),refresh:s("refresh",60215),regex:s("regex",60216),remoteExplorer:s("remote-explorer",60217),remote:s("remote",60218),remove:s("remove",60219),replaceAll:s("replace-all",60220),replace:s("replace",60221),repoClone:s("repo-clone",60222),repoForcePush:s("repo-force-push",60223),repoPull:s("repo-pull",60224),repoPush:s("repo-push",60225),report:s("report",60226),requestChanges:s("request-changes",60227),rocket:s("rocket",60228),rootFolderOpened:s("root-folder-opened",60229),rootFolder:s("root-folder",60230),rss:s("rss",60231),ruby:s("ruby",60232),saveAll:s("save-all",60233),saveAs:s("save-as",60234),save:s("save",60235),screenFull:s("screen-full",60236),screenNormal:s("screen-normal",60237),searchStop:s("search-stop",60238),server:s("server",60240),settingsGear:s("settings-gear",60241),settings:s("settings",60242),shield:s("shield",60243),smiley:s("smiley",60244),sortPrecedence:s("sort-precedence",60245),splitHorizontal:s("split-horizontal",60246),splitVertical:s("split-vertical",60247),squirrel:s("squirrel",60248),starFull:s("star-full",60249),starHalf:s("star-half",60250),symbolClass:s("symbol-class",60251),symbolColor:s("symbol-color",60252),symbolConstant:s("symbol-constant",60253),symbolEnumMember:s("symbol-enum-member",60254),symbolField:s("symbol-field",60255),symbolFile:s("symbol-file",60256),symbolInterface:s("symbol-interface",60257),symbolKeyword:s("symbol-keyword",60258),symbolMisc:s("symbol-misc",60259),symbolOperator:s("symbol-operator",60260),symbolProperty:s("symbol-property",60261),wrench:s("wrench",60261),wrenchSubaction:s("wrench-subaction",60261),symbolSnippet:s("symbol-snippet",60262),tasklist:s("tasklist",60263),telescope:s("telescope",60264),textSize:s("text-size",60265),threeBars:s("three-bars",60266),thumbsdown:s("thumbsdown",60267),thumbsup:s("thumbsup",60268),tools:s("tools",60269),triangleDown:s("triangle-down",60270),triangleLeft:s("triangle-left",60271),triangleRight:s("triangle-right",60272),triangleUp:s("triangle-up",60273),twitter:s("twitter",60274),unfold:s("unfold",60275),unlock:s("unlock",60276),unmute:s("unmute",60277),unverified:s("unverified",60278),verified:s("verified",60279),versions:s("versions",60280),vmActive:s("vm-active",60281),vmOutline:s("vm-outline",60282),vmRunning:s("vm-running",60283),watch:s("watch",60284),whitespace:s("whitespace",60285),wholeWord:s("whole-word",60286),window:s("window",60287),wordWrap:s("word-wrap",60288),zoomIn:s("zoom-in",60289),zoomOut:s("zoom-out",60290),listFilter:s("list-filter",60291),listFlat:s("list-flat",60292),listSelection:s("list-selection",60293),selection:s("selection",60293),listTree:s("list-tree",60294),debugBreakpointFunctionUnverified:s("debug-breakpoint-function-unverified",60295),debugBreakpointFunction:s("debug-breakpoint-function",60296),debugBreakpointFunctionDisabled:s("debug-breakpoint-function-disabled",60296),debugStackframeActive:s("debug-stackframe-active",60297),circleSmallFilled:s("circle-small-filled",60298),debugStackframeDot:s("debug-stackframe-dot",60298),terminalDecorationMark:s("terminal-decoration-mark",60298),debugStackframe:s("debug-stackframe",60299),debugStackframeFocused:s("debug-stackframe-focused",60299),debugBreakpointUnsupported:s("debug-breakpoint-unsupported",60300),symbolString:s("symbol-string",60301),debugReverseContinue:s("debug-reverse-continue",60302),debugStepBack:s("debug-step-back",60303),debugRestartFrame:s("debug-restart-frame",60304),debugAlt:s("debug-alt",60305),callIncoming:s("call-incoming",60306),callOutgoing:s("call-outgoing",60307),menu:s("menu",60308),expandAll:s("expand-all",60309),feedback:s("feedback",60310),gitPullRequestReviewer:s("git-pull-request-reviewer",60310),groupByRefType:s("group-by-ref-type",60311),ungroupByRefType:s("ungroup-by-ref-type",60312),account:s("account",60313),gitPullRequestAssignee:s("git-pull-request-assignee",60313),bellDot:s("bell-dot",60314),debugConsole:s("debug-console",60315),library:s("library",60316),output:s("output",60317),runAll:s("run-all",60318),syncIgnored:s("sync-ignored",60319),pinned:s("pinned",60320),githubInverted:s("github-inverted",60321),serverProcess:s("server-process",60322),serverEnvironment:s("server-environment",60323),pass:s("pass",60324),issueClosed:s("issue-closed",60324),stopCircle:s("stop-circle",60325),playCircle:s("play-circle",60326),record:s("record",60327),debugAltSmall:s("debug-alt-small",60328),vmConnect:s("vm-connect",60329),cloud:s("cloud",60330),merge:s("merge",60331),export:s("export",60332),graphLeft:s("graph-left",60333),magnet:s("magnet",60334),notebook:s("notebook",60335),redo:s("redo",60336),checkAll:s("check-all",60337),pinnedDirty:s("pinned-dirty",60338),passFilled:s("pass-filled",60339),circleLargeFilled:s("circle-large-filled",60340),circleLarge:s("circle-large",60341),circleLargeOutline:s("circle-large-outline",60341),combine:s("combine",60342),gather:s("gather",60342),table:s("table",60343),variableGroup:s("variable-group",60344),typeHierarchy:s("type-hierarchy",60345),typeHierarchySub:s("type-hierarchy-sub",60346),typeHierarchySuper:s("type-hierarchy-super",60347),gitPullRequestCreate:s("git-pull-request-create",60348),runAbove:s("run-above",60349),runBelow:s("run-below",60350),notebookTemplate:s("notebook-template",60351),debugRerun:s("debug-rerun",60352),workspaceTrusted:s("workspace-trusted",60353),workspaceUntrusted:s("workspace-untrusted",60354),workspaceUnknown:s("workspace-unknown",60355),terminalCmd:s("terminal-cmd",60356),terminalDebian:s("terminal-debian",60357),terminalLinux:s("terminal-linux",60358),terminalPowershell:s("terminal-powershell",60359),terminalTmux:s("terminal-tmux",60360),terminalUbuntu:s("terminal-ubuntu",60361),terminalBash:s("terminal-bash",60362),arrowSwap:s("arrow-swap",60363),copy:s("copy",60364),personAdd:s("person-add",60365),filterFilled:s("filter-filled",60366),wand:s("wand",60367),debugLineByLine:s("debug-line-by-line",60368),inspect:s("inspect",60369),layers:s("layers",60370),layersDot:s("layers-dot",60371),layersActive:s("layers-active",60372),compass:s("compass",60373),compassDot:s("compass-dot",60374),compassActive:s("compass-active",60375),azure:s("azure",60376),issueDraft:s("issue-draft",60377),gitPullRequestClosed:s("git-pull-request-closed",60378),gitPullRequestDraft:s("git-pull-request-draft",60379),debugAll:s("debug-all",60380),debugCoverage:s("debug-coverage",60381),runErrors:s("run-errors",60382),folderLibrary:s("folder-library",60383),debugContinueSmall:s("debug-continue-small",60384),beakerStop:s("beaker-stop",60385),graphLine:s("graph-line",60386),graphScatter:s("graph-scatter",60387),pieChart:s("pie-chart",60388),bracket:s("bracket",60175),bracketDot:s("bracket-dot",60389),bracketError:s("bracket-error",60390),lockSmall:s("lock-small",60391),azureDevops:s("azure-devops",60392),verifiedFilled:s("verified-filled",60393),newline:s("newline",60394),layout:s("layout",60395),layoutActivitybarLeft:s("layout-activitybar-left",60396),layoutActivitybarRight:s("layout-activitybar-right",60397),layoutPanelLeft:s("layout-panel-left",60398),layoutPanelCenter:s("layout-panel-center",60399),layoutPanelJustify:s("layout-panel-justify",60400),layoutPanelRight:s("layout-panel-right",60401),layoutPanel:s("layout-panel",60402),layoutSidebarLeft:s("layout-sidebar-left",60403),layoutSidebarRight:s("layout-sidebar-right",60404),layoutStatusbar:s("layout-statusbar",60405),layoutMenubar:s("layout-menubar",60406),layoutCentered:s("layout-centered",60407),target:s("target",60408),indent:s("indent",60409),recordSmall:s("record-small",60410),errorSmall:s("error-small",60411),terminalDecorationError:s("terminal-decoration-error",60411),arrowCircleDown:s("arrow-circle-down",60412),arrowCircleLeft:s("arrow-circle-left",60413),arrowCircleRight:s("arrow-circle-right",60414),arrowCircleUp:s("arrow-circle-up",60415),layoutSidebarRightOff:s("layout-sidebar-right-off",60416),layoutPanelOff:s("layout-panel-off",60417),layoutSidebarLeftOff:s("layout-sidebar-left-off",60418),blank:s("blank",60419),heartFilled:s("heart-filled",60420),map:s("map",60421),mapHorizontal:s("map-horizontal",60421),foldHorizontal:s("fold-horizontal",60421),mapFilled:s("map-filled",60422),mapHorizontalFilled:s("map-horizontal-filled",60422),foldHorizontalFilled:s("fold-horizontal-filled",60422),circleSmall:s("circle-small",60423),bellSlash:s("bell-slash",60424),bellSlashDot:s("bell-slash-dot",60425),commentUnresolved:s("comment-unresolved",60426),gitPullRequestGoToChanges:s("git-pull-request-go-to-changes",60427),gitPullRequestNewChanges:s("git-pull-request-new-changes",60428),searchFuzzy:s("search-fuzzy",60429),commentDraft:s("comment-draft",60430),send:s("send",60431),sparkle:s("sparkle",60432),insert:s("insert",60433),mic:s("mic",60434),thumbsdownFilled:s("thumbsdown-filled",60435),thumbsupFilled:s("thumbsup-filled",60436),coffee:s("coffee",60437),snake:s("snake",60438),game:s("game",60439),vr:s("vr",60440),chip:s("chip",60441),piano:s("piano",60442),music:s("music",60443),micFilled:s("mic-filled",60444),repoFetch:s("repo-fetch",60445),copilot:s("copilot",60446),lightbulbSparkle:s("lightbulb-sparkle",60447),robot:s("robot",60448),sparkleFilled:s("sparkle-filled",60449),diffSingle:s("diff-single",60450),diffMultiple:s("diff-multiple",60451),surroundWith:s("surround-with",60452),share:s("share",60453),gitStash:s("git-stash",60454),gitStashApply:s("git-stash-apply",60455),gitStashPop:s("git-stash-pop",60456),vscode:s("vscode",60457),vscodeInsiders:s("vscode-insiders",60458),codeOss:s("code-oss",60459),runCoverage:s("run-coverage",60460),runAllCoverage:s("run-all-coverage",60461),coverage:s("coverage",60462),githubProject:s("github-project",60463),mapVertical:s("map-vertical",60464),foldVertical:s("fold-vertical",60464),mapVerticalFilled:s("map-vertical-filled",60465),foldVerticalFilled:s("fold-vertical-filled",60465),goToSearch:s("go-to-search",60466),percentage:s("percentage",60467),sortPercentage:s("sort-percentage",60467),attach:s("attach",60468)},...{dialogError:s("dialog-error","error"),dialogWarning:s("dialog-warning","warning"),dialogInfo:s("dialog-info","info"),dialogClose:s("dialog-close","close"),treeItemExpanded:s("tree-item-expanded","chevron-down"),treeFilterOnTypeOn:s("tree-filter-on-type-on","list-filter"),treeFilterOnTypeOff:s("tree-filter-on-type-off","list-selection"),treeFilterClear:s("tree-filter-clear","close"),treeItemLoading:s("tree-item-loading","loading"),menuSelection:s("menu-selection","check"),menuSubmenu:s("menu-submenu","chevron-right"),menuBarMore:s("menubar-more","more"),scrollbarButtonLeft:s("scrollbar-button-left","triangle-left"),scrollbarButtonRight:s("scrollbar-button-right","triangle-right"),scrollbarButtonUp:s("scrollbar-button-up","triangle-up"),scrollbarButtonDown:s("scrollbar-button-down","triangle-down"),toolBarMore:s("toolbar-more","more"),quickInputBack:s("quick-input-back","arrow-left"),dropDownButton:s("drop-down-button",60084),symbolCustomColor:s("symbol-customcolor",60252),exportIcon:s("export",60332),workspaceUnspecified:s("workspace-unspecified",60355),newLine:s("newline",60394),thumbsDownFilled:s("thumbsdown-filled",60435),thumbsUpFilled:s("thumbsup-filled",60436),gitFetch:s("git-fetch",60445),lightbulbSparkleAutofix:s("lightbulb-sparkle-autofix",60447),debugBreakpointPending:s("debug-breakpoint-pending",60377)}}},9861:(e,t,n)=>{"use strict";function r(e,t,n=(e,t)=>e===t){if(e===t)return!0;if(!e||!t)return!1;if(e.length!==t.length)return!1;for(let r=0,i=e.length;re){const n=new Set;return e.filter((e=>{const r=t(e);return!n.has(r)&&(n.add(r),!0)}))}function l(e,t){return e.length>0?e[0]:t}function c(e,t,n){const r=e.slice(0,t),i=e.slice(t);return r.concat(n,i)}function h(e,t){for(const n of t)e.push(n)}var u;function d(e,t){return(n,r)=>t(e(n),e(r))}n.d(t,{E4:()=>h,Fy:()=>l,Hw:()=>f,U9:()=>g,VE:()=>d,aI:()=>r,c1:()=>p,dM:()=>a,j3:()=>m,kj:()=>o,n:()=>i,nK:()=>c,pN:()=>s}),function(e){e.isLessThan=function(e){return e<0},e.isLessThanOrEqual=function(e){return e<=0},e.isGreaterThan=function(e){return e>0},e.isNeitherLessOrGreaterThan=function(e){return 0===e},e.greaterThan=1,e.lessThan=-1,e.neitherLessOrGreaterThan=0}(u||(u={}));const g=(e,t)=>e-t;function f(e){return(t,n)=>-e(t,n)}class m{constructor(e){this.items=e,this.firstIdx=0,this.lastIdx=this.items.length-1}get length(){return this.lastIdx-this.firstIdx+1}takeWhile(e){let t=this.firstIdx;for(;t=0&&e(this.items[t]);)t--;const n=t===this.lastIdx?null:this.items.slice(t+1,this.lastIdx+1);return this.lastIdx=t,n}peek(){if(0!==this.length)return this.items[this.firstIdx]}dequeue(){const e=this.items[this.firstIdx];return this.firstIdx++,e}takeCount(e){const t=this.items.slice(this.firstIdx,this.firstIdx+e);return this.firstIdx+=e,t}}class p{static{this.empty=new p((e=>{}))}constructor(e){this.iterate=e}toArray(){const e=[];return this.iterate((t=>(e.push(t),!0))),e}filter(e){return new p((t=>this.iterate((n=>!e(n)||t(n)))))}map(e){return new p((t=>this.iterate((n=>t(e(n))))))}findLast(e){let t;return this.iterate((n=>(e(n)&&(t=n),!0))),t}findLastMaxBy(e){let t,n=!0;return this.iterate((r=>((n||u.isGreaterThan(e(r,t)))&&(n=!1,t=r),!0))),t}}},9908:(e,t,n)=>{"use strict";n.r(t),n.d(t,{clearPlatformLanguageAssociations:()=>f,getLanguageIds:()=>m,registerPlatformLanguageAssociation:()=>g});var r=n(6958),i=n(1939),s=n(6456),o=n(8821),a=n(9403),l=n(1508),c=n(3941);let h=[],u=[],d=[];function g(e,t=!1){!function(e,t,n){const i=function(e,t){return{id:e.id,mime:e.mime,filename:e.filename,extension:e.extension,filepattern:e.filepattern,firstline:e.firstline,userConfigured:t,filenameLowercase:e.filename?e.filename.toLowerCase():void 0,extensionLowercase:e.extension?e.extension.toLowerCase():void 0,filepatternLowercase:e.filepattern?(0,r.qg)(e.filepattern.toLowerCase()):void 0,filepatternOnPath:!!e.filepattern&&e.filepattern.indexOf(o.SA.sep)>=0}}(e,t);h.push(i),i.userConfigured?d.push(i):u.push(i);n&&!i.userConfigured&&h.forEach((e=>{e.mime===i.mime||e.userConfigured||(i.extension&&e.extension===i.extension&&console.warn(`Overwriting extension <<${i.extension}>> to now point to mime <<${i.mime}>>`),i.filename&&e.filename===i.filename&&console.warn(`Overwriting filename <<${i.filename}>> to now point to mime <<${i.mime}>>`),i.filepattern&&e.filepattern===i.filepattern&&console.warn(`Overwriting filepattern <<${i.filepattern}>> to now point to mime <<${i.mime}>>`),i.firstline&&e.firstline===i.firstline&&console.warn(`Overwriting firstline <<${i.firstline}>> to now point to mime <<${i.mime}>>`))}))}(e,!1,t)}function f(){h=h.filter((e=>e.userConfigured)),u=[]}function m(e,t){return function(e,t){let n;if(e)switch(e.scheme){case s.ny.file:n=e.fsPath;break;case s.ny.data:n=a.B6.parseMetaData(e).get(a.B6.META_DATA_LABEL);break;case s.ny.vscodeNotebookCell:n=void 0;break;default:n=e.path}if(!n)return[{id:"unknown",mime:i.K.unknown}];n=n.toLowerCase();const r=(0,o.P8)(n),g=p(n,r,d);if(g)return[g,{id:c.vH,mime:i.K.text}];const f=p(n,r,u);if(f)return[f,{id:c.vH,mime:i.K.text}];if(t){const e=function(e){(0,l.LU)(e)&&(e=e.substr(1));if(e.length>0)for(let t=h.length-1;t>=0;t--){const n=h[t];if(!n.firstline)continue;const r=e.match(n.firstline);if(r&&r.length>0)return n}return}(t);if(e)return[e,{id:c.vH,mime:i.K.text}]}return[{id:"unknown",mime:i.K.unknown}]}(e,t).map((e=>e.id))}function p(e,t,n){let r,i,s;for(let o=n.length-1;o>=0;o--){const a=n[o];if(t===a.filenameLowercase){r=a;break}if(a.filepattern&&(!i||a.filepattern.length>i.filepattern.length)){const n=a.filepatternOnPath?e:t;a.filepatternLowercase?.(n)&&(i=a)}a.extension&&(!s||a.extension.length>s.extension.length)&&t.endsWith(a.extensionLowercase)&&(s=a)}return r||(i||(s||void 0))}}},t={};function n(r){var i=t[r];if(void 0!==i)return i.exports;var s=t[r]={exports:{}};return e[r](s,s.exports,n),s.exports}n.d=(e,t)=>{for(var r in t)n.o(t,r)&&!n.o(e,r)&&Object.defineProperty(e,r,{enumerable:!0,get:t[r]})},n.e=()=>Promise.resolve(),n.o=(e,t)=>Object.prototype.hasOwnProperty.call(e,t),n.r=e=>{"undefined"!==typeof Symbol&&Symbol.toStringTag&&Object.defineProperty(e,Symbol.toStringTag,{value:"Module"}),Object.defineProperty(e,"__esModule",{value:!0})},(()=>{"use strict";var e=n(1929),t=n(5196),r=n(718);let i=!1;function s(n){if(i)return;i=!0;const s=new e.SimpleWorkerServer((e=>{globalThis.postMessage(e)}),(e=>new t.EditorSimpleWorker(r.EditorWorkerHost.getChannel(e),n)));globalThis.onmessage=e=>{s.onmessage(e.data)}}function o(e,t=!1){const n=e.length;let r=0,i="",s=0,o=16,h=0,u=0,d=0,g=0,f=0;function m(t,n){let i=0,s=0;for(;i=48&&t<=57)s=16*s+t-48;else if(t>=65&&t<=70)s=16*s+t-65+10;else{if(!(t>=97&&t<=102))break;s=16*s+t-97+10}r++,i++}return i=n)return s=n,o=17;let t=e.charCodeAt(r);if(a(t)){do{r++,i+=String.fromCharCode(t),t=e.charCodeAt(r)}while(a(t));return o=15}if(l(t))return r++,i+=String.fromCharCode(t),13===t&&10===e.charCodeAt(r)&&(r++,i+="\n"),h++,d=r,o=14;switch(t){case 123:return r++,o=1;case 125:return r++,o=2;case 91:return r++,o=3;case 93:return r++,o=4;case 58:return r++,o=6;case 44:return r++,o=5;case 34:return r++,i=function(){let t="",i=r;for(;;){if(r>=n){t+=e.substring(i,r),f=2;break}const s=e.charCodeAt(r);if(34===s){t+=e.substring(i,r),r++;break}if(92!==s){if(s>=0&&s<=31){if(l(s)){t+=e.substring(i,r),f=2;break}f=6}r++}else{if(t+=e.substring(i,r),r++,r>=n){f=2;break}switch(e.charCodeAt(r++)){case 34:t+='"';break;case 92:t+="\\";break;case 47:t+="/";break;case 98:t+="\b";break;case 102:t+="\f";break;case 110:t+="\n";break;case 114:t+="\r";break;case 116:t+="\t";break;case 117:const e=m(4,!0);e>=0?t+=String.fromCharCode(e):f=4;break;default:f=5}i=r}}return t}(),o=10;case 47:const a=r-1;if(47===e.charCodeAt(r+1)){for(r+=2;rr,scan:t?function(){let e;do{e=p()}while(e>=12&&e<=15);return e}:p,getToken:()=>o,getTokenValue:()=>i,getTokenOffset:()=>s,getTokenLength:()=>r-s,getTokenStartLine:()=>u,getTokenStartCharacter:()=>s-g,getTokenError:()=>f}}function a(e){return 32===e||9===e}function l(e){return 10===e||13===e}function c(e){return e>=48&&e<=57}var h,u;globalThis.onmessage=e=>{i||s(null)},(u=h||(h={}))[u.lineFeed=10]="lineFeed",u[u.carriageReturn=13]="carriageReturn",u[u.space=32]="space",u[u._0=48]="_0",u[u._1=49]="_1",u[u._2=50]="_2",u[u._3=51]="_3",u[u._4=52]="_4",u[u._5=53]="_5",u[u._6=54]="_6",u[u._7=55]="_7",u[u._8=56]="_8",u[u._9=57]="_9",u[u.a=97]="a",u[u.b=98]="b",u[u.c=99]="c",u[u.d=100]="d",u[u.e=101]="e",u[u.f=102]="f",u[u.g=103]="g",u[u.h=104]="h",u[u.i=105]="i",u[u.j=106]="j",u[u.k=107]="k",u[u.l=108]="l",u[u.m=109]="m",u[u.n=110]="n",u[u.o=111]="o",u[u.p=112]="p",u[u.q=113]="q",u[u.r=114]="r",u[u.s=115]="s",u[u.t=116]="t",u[u.u=117]="u",u[u.v=118]="v",u[u.w=119]="w",u[u.x=120]="x",u[u.y=121]="y",u[u.z=122]="z",u[u.A=65]="A",u[u.B=66]="B",u[u.C=67]="C",u[u.D=68]="D",u[u.E=69]="E",u[u.F=70]="F",u[u.G=71]="G",u[u.H=72]="H",u[u.I=73]="I",u[u.J=74]="J",u[u.K=75]="K",u[u.L=76]="L",u[u.M=77]="M",u[u.N=78]="N",u[u.O=79]="O",u[u.P=80]="P",u[u.Q=81]="Q",u[u.R=82]="R",u[u.S=83]="S",u[u.T=84]="T",u[u.U=85]="U",u[u.V=86]="V",u[u.W=87]="W",u[u.X=88]="X",u[u.Y=89]="Y",u[u.Z=90]="Z",u[u.asterisk=42]="asterisk",u[u.backslash=92]="backslash",u[u.closeBrace=125]="closeBrace",u[u.closeBracket=93]="closeBracket",u[u.colon=58]="colon",u[u.comma=44]="comma",u[u.dot=46]="dot",u[u.doubleQuote=34]="doubleQuote",u[u.minus=45]="minus",u[u.openBrace=123]="openBrace",u[u.openBracket=91]="openBracket",u[u.plus=43]="plus",u[u.slash=47]="slash",u[u.formFeed=12]="formFeed",u[u.tab=9]="tab";var d,g=new Array(20).fill(0).map(((e,t)=>" ".repeat(t))),f=200,m={" ":{"\n":new Array(f).fill(0).map(((e,t)=>"\n"+" ".repeat(t))),"\r":new Array(f).fill(0).map(((e,t)=>"\r"+" ".repeat(t))),"\r\n":new Array(f).fill(0).map(((e,t)=>"\r\n"+" ".repeat(t)))},"\t":{"\n":new Array(f).fill(0).map(((e,t)=>"\n"+"\t".repeat(t))),"\r":new Array(f).fill(0).map(((e,t)=>"\r"+"\t".repeat(t))),"\r\n":new Array(f).fill(0).map(((e,t)=>"\r\n"+"\t".repeat(t)))}},p=["\n","\r","\r\n"];function b(e,t,n){let r,i,s,a,l;if(t){for(a=t.offset,l=a+t.length,s=a;s>0&&!k(e,s-1);)s--;let o=l;for(;o1)return _(c,d)+_(u,r+f);const e=u.length*(r+f);return!h||e>m[b][c].length?c+_(u,r+f):e<=0?c:m[b][c][e]}function L(){let e=v.scan();for(d=0;15===e||14===e;)14===e&&n.keepLines?d+=1:14===e&&(d=1),e=v.scan();return C=16===e||0!==v.getTokenError(),e}const w=[];function S(n,r,i){C||t&&!(ra)||e.substring(r,i)===n||w.push({offset:r,length:i-r,content:n})}let x=L();if(n.keepLines&&d>0&&S(_(c,d),0,0),17!==x){let e=v.getTokenOffset()+s;S(u.length*r<20&&n.insertSpaces?g[u.length*r]:_(u,r),s,e)}for(;17!==x;){let e=v.getTokenOffset()+v.getTokenLength()+s,t=L(),r="",i=!1;for(;0===d&&(12===t||13===t);){let n=v.getTokenOffset()+s;S(g[1],e,n),e=v.getTokenOffset()+v.getTokenLength()+s,i=12===t,r=i?y():"",t=L()}if(2===t)1!==x&&f--,n.keepLines&&d>0||!n.keepLines&&1!==x?r=y():n.keepLines&&(r=g[1]);else if(4===t)3!==x&&f--,n.keepLines&&d>0||!n.keepLines&&3!==x?r=y():n.keepLines&&(r=g[1]);else{switch(x){case 3:case 1:f++,r=n.keepLines&&d>0||!n.keepLines?y():g[1];break;case 5:r=n.keepLines&&d>0||!n.keepLines?y():g[1];break;case 12:r=y();break;case 13:d>0?r=y():i||(r=g[1]);break;case 6:n.keepLines&&d>0?r=y():i||(r=g[1]);break;case 10:n.keepLines&&d>0?r=y():6!==t||i||(r="");break;case 7:case 8:case 9:case 11:case 2:case 4:n.keepLines&&d>0?r=y():12!==t&&13!==t||i?5!==t&&17!==t&&(C=!0):r=g[1];break;case 16:C=!0}d>0&&(12===t||13===t)&&(r=y())}17===t&&(r=n.keepLines&&d>0?y():n.insertFinalNewline?c:"");S(r,e,v.getTokenOffset()+s),x=t}return w}function _(e,t){let n="";for(let r=0;re(r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter()):()=>!0}function a(e){return e?()=>e(r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter(),(()=>i.slice())):()=>!0}function l(e){return e?t=>e(t,r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter()):()=>!0}function c(e){return e?t=>e(t,r.getTokenOffset(),r.getTokenLength(),r.getTokenStartLine(),r.getTokenStartCharacter(),(()=>i.slice())):()=>!0}const h=a(t.onObjectBegin),u=c(t.onObjectProperty),g=s(t.onObjectEnd),f=a(t.onArrayBegin),m=s(t.onArrayEnd),p=c(t.onLiteralValue),b=l(t.onSeparator),_=s(t.onComment),k=l(t.onError),v=n&&n.disallowComments,C=n&&n.allowTrailingComma;function y(){for(;;){const e=r.scan();switch(r.getTokenError()){case 4:L(14);break;case 5:L(15);break;case 3:L(13);break;case 1:v||L(11);break;case 2:L(12);break;case 6:L(16)}switch(e){case 12:case 13:v?L(10):_();break;case 16:L(1);break;case 15:case 14:break;default:return e}}}function L(e,t=[],n=[]){if(k(e),t.length+n.length>0){let e=r.getToken();for(;17!==e;){if(-1!==t.indexOf(e)){y();break}if(-1!==n.indexOf(e))break;e=y()}}}function w(e){const t=r.getTokenValue();return e?p(t):(u(t),i.push(t)),y(),!0}function S(){switch(r.getToken()){case 11:const e=r.getTokenValue();let t=Number(e);isNaN(t)&&(L(2),t=0),p(t);break;case 7:p(null);break;case 8:p(!0);break;case 9:p(!1);break;default:return!1}return y(),!0}function x(){return 10!==r.getToken()?(L(3,[],[2,5]),!1):(w(!1),6===r.getToken()?(b(":"),y(),T()||L(4,[],[2,5])):L(5,[],[2,5]),i.pop(),!0)}function E(){h(),y();let e=!1;for(;2!==r.getToken()&&17!==r.getToken();){if(5===r.getToken()){if(e||L(4,[],[]),b(","),y(),2===r.getToken()&&C)break}else e&&L(6,[],[]);x()||L(4,[],[2,5]),e=!0}return g(),2!==r.getToken()?L(7,[2],[]):y(),!0}function N(){f(),y();let e=!0,t=!1;for(;4!==r.getToken()&&17!==r.getToken();){if(5===r.getToken()){if(t||L(4,[],[]),b(","),y(),4===r.getToken()&&C)break}else t&&L(6,[],[]);e?(i.push(0),e=!1):i[i.length-1]++,T()||L(4,[],[4,5]),t=!0}return m(),e||i.pop(),4!==r.getToken()?L(8,[4],[]):y(),!0}function T(){switch(r.getToken()){case 3:return N();case 1:return E();case 10:return w(!0);default:return S()}}if(y(),17===r.getToken())return!!n.allowEmptyContent||(L(4,[],[]),!1);if(!T())return L(4,[],[]),!1;17!==r.getToken()&&L(9,[],[])}(e,{onObjectBegin:()=>{const e={};a(e),s.push(i),i=e,r=null},onObjectProperty:e=>{r=e},onObjectEnd:()=>{i=s.pop()},onArrayBegin:()=>{const e=[];a(e),s.push(i),i=e,r=null},onArrayEnd:()=>{i=s.pop()},onLiteralValue:a,onError:(e,n,r)=>{t.push({error:e,offset:n,length:r})}},n),i[0]},Zt=function e(t,n,r=!1){if(function(e,t,n=!1){return t>=e.offset&&t0?e.lastIndexOf(t)===n:0===n&&e===t}function hn(e){let t="";(function(e,t){if(e.length0&&(r.arguments=n),r},ae.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.title)&&dn.string(t.command)},(ce=le||(le={})).replace=function(e,t){return{range:e,newText:t}},ce.insert=function(e,t){return{range:{start:e,end:e},newText:t}},ce.del=function(e){return{range:e,newText:""}},ce.is=function(e){const t=e;return dn.objectLiteral(t)&&dn.string(t.newText)&&D.is(t.range)},(ue=he||(he={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},ue.is=function(e){const t=e;return dn.objectLiteral(t)&&dn.string(t.label)&&(dn.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(dn.string(t.description)||void 0===t.description)},(de||(de={})).is=function(e){const t=e;return dn.string(t)},(fe=ge||(ge={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},fe.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},fe.del=function(e,t){return{range:e,newText:"",annotationId:t}},fe.is=function(e){const t=e;return le.is(t)&&(he.is(t.annotationId)||de.is(t.annotationId))},(pe=me||(me={})).create=function(e,t){return{textDocument:e,edits:t}},pe.is=function(e){let t=e;return dn.defined(t)&&Ne.is(t.textDocument)&&Array.isArray(t.edits)},(_e=be||(be={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},_e.is=function(e){let t=e;return t&&"create"===t.kind&&dn.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||dn.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||dn.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||de.is(t.annotationId))},(ve=ke||(ke={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},ve.is=function(e){let t=e;return t&&"rename"===t.kind&&dn.string(t.oldUri)&&dn.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||dn.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||dn.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||de.is(t.annotationId))},(ye=Ce||(Ce={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},ye.is=function(e){let t=e;return t&&"delete"===t.kind&&dn.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||dn.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||dn.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||de.is(t.annotationId))},(Le||(Le={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>dn.string(e.kind)?be.is(e)||ke.is(e)||Ce.is(e):me.is(e))))},(Se=we||(we={})).create=function(e){return{uri:e}},Se.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)},(Ee=xe||(xe={})).create=function(e,t){return{uri:e,version:t}},Ee.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)&&dn.integer(t.version)},(Te=Ne||(Ne={})).create=function(e,t){return{uri:e,version:t}},Te.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)&&(null===t.version||dn.integer(t.version))},(Ie=Ae||(Ae={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},Ie.is=function(e){let t=e;return dn.defined(t)&&dn.string(t.uri)&&dn.string(t.languageId)&&dn.integer(t.version)&&dn.string(t.text)},(Me=Oe||(Oe={})).PlainText="plaintext",Me.Markdown="markdown",Me.is=function(e){const t=e;return t===Me.PlainText||t===Me.Markdown},(Re||(Re={})).is=function(e){const t=e;return dn.objectLiteral(e)&&Oe.is(t.kind)&&dn.string(t.value)},(Be=De||(De={})).Text=1,Be.Method=2,Be.Function=3,Be.Constructor=4,Be.Field=5,Be.Variable=6,Be.Class=7,Be.Interface=8,Be.Module=9,Be.Property=10,Be.Unit=11,Be.Value=12,Be.Enum=13,Be.Keyword=14,Be.Snippet=15,Be.Color=16,Be.File=17,Be.Reference=18,Be.Folder=19,Be.EnumMember=20,Be.Constant=21,Be.Struct=22,Be.Event=23,Be.Operator=24,Be.TypeParameter=25,(Pe=Fe||(Fe={})).PlainText=1,Pe.Snippet=2,(Ve||(Ve={})).Deprecated=1,(je=ze||(ze={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},je.is=function(e){const t=e;return t&&dn.string(t.newText)&&D.is(t.insert)&&D.is(t.replace)},(We=qe||(qe={})).asIs=1,We.adjustIndentation=2,(Ue||(Ue={})).is=function(e){const t=e;return t&&(dn.string(t.detail)||void 0===t.detail)&&(dn.string(t.description)||void 0===t.description)},($e||($e={})).create=function(e){return{label:e}},(He||(He={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(Ge=Ke||(Ke={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},Ge.is=function(e){const t=e;return dn.string(t)||dn.objectLiteral(t)&&dn.string(t.language)&&dn.string(t.value)},(Qe||(Qe={})).is=function(e){let t=e;return!!t&&dn.objectLiteral(t)&&(Re.is(t.contents)||Ke.is(t.contents)||dn.typedArray(t.contents,Ke.is))&&(void 0===e.range||D.is(e.range))},(Je||(Je={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(Xe||(Xe={})).create=function(e,t,...n){let r={label:e};return dn.defined(t)&&(r.documentation=t),dn.defined(n)?r.parameters=n:r.parameters=[],r},(Ze=Ye||(Ye={})).Text=1,Ze.Read=2,Ze.Write=3,(et||(et={})).create=function(e,t){let n={range:e};return dn.number(t)&&(n.kind=t),n},(nt=tt||(tt={})).File=1,nt.Module=2,nt.Namespace=3,nt.Package=4,nt.Class=5,nt.Method=6,nt.Property=7,nt.Field=8,nt.Constructor=9,nt.Enum=10,nt.Interface=11,nt.Function=12,nt.Variable=13,nt.Constant=14,nt.String=15,nt.Number=16,nt.Boolean=17,nt.Array=18,nt.Object=19,nt.Key=20,nt.Null=21,nt.EnumMember=22,nt.Struct=23,nt.Event=24,nt.Operator=25,nt.TypeParameter=26,(rt||(rt={})).Deprecated=1,(it||(it={})).create=function(e,t,n,r,i){let s={name:e,kind:t,location:{uri:r,range:n}};return i&&(s.containerName=i),s},(st||(st={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},(at=ot||(ot={})).create=function(e,t,n,r,i,s){let o={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==s&&(o.children=s),o},at.is=function(e){let t=e;return t&&dn.string(t.name)&&dn.number(t.kind)&&D.is(t.range)&&D.is(t.selectionRange)&&(void 0===t.detail||dn.string(t.detail))&&(void 0===t.deprecated||dn.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},(ct=lt||(lt={})).Empty="",ct.QuickFix="quickfix",ct.Refactor="refactor",ct.RefactorExtract="refactor.extract",ct.RefactorInline="refactor.inline",ct.RefactorRewrite="refactor.rewrite",ct.Source="source",ct.SourceOrganizeImports="source.organizeImports",ct.SourceFixAll="source.fixAll",(ut=ht||(ht={})).Invoked=1,ut.Automatic=2,(gt=dt||(dt={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},gt.is=function(e){let t=e;return dn.defined(t)&&dn.typedArray(t.diagnostics,ie.is)&&(void 0===t.only||dn.typedArray(t.only,dn.string))&&(void 0===t.triggerKind||t.triggerKind===ht.Invoked||t.triggerKind===ht.Automatic)},(mt=ft||(ft={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):oe.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},mt.is=function(e){let t=e;return t&&dn.string(t.title)&&(void 0===t.diagnostics||dn.typedArray(t.diagnostics,ie.is))&&(void 0===t.kind||dn.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||oe.is(t.command))&&(void 0===t.isPreferred||dn.boolean(t.isPreferred))&&(void 0===t.edit||Le.is(t.edit))},(bt=pt||(pt={})).create=function(e,t){let n={range:e};return dn.defined(t)&&(n.data=t),n},bt.is=function(e){let t=e;return dn.defined(t)&&D.is(t.range)&&(dn.undefined(t.command)||oe.is(t.command))},(kt=_t||(_t={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},kt.is=function(e){let t=e;return dn.defined(t)&&dn.uinteger(t.tabSize)&&dn.boolean(t.insertSpaces)},(Ct=vt||(vt={})).create=function(e,t,n){return{range:e,target:t,data:n}},Ct.is=function(e){let t=e;return dn.defined(t)&&D.is(t.range)&&(dn.undefined(t.target)||dn.string(t.target))},(Lt=yt||(yt={})).create=function(e,t){return{range:e,parent:t}},Lt.is=function(e){let t=e;return dn.objectLiteral(t)&&D.is(t.range)&&(void 0===t.parent||Lt.is(t.parent))},(St=wt||(wt={})).namespace="namespace",St.type="type",St.class="class",St.enum="enum",St.interface="interface",St.struct="struct",St.typeParameter="typeParameter",St.parameter="parameter",St.variable="variable",St.property="property",St.enumMember="enumMember",St.event="event",St.function="function",St.method="method",St.macro="macro",St.keyword="keyword",St.modifier="modifier",St.comment="comment",St.string="string",St.number="number",St.regexp="regexp",St.operator="operator",St.decorator="decorator",(Et=xt||(xt={})).declaration="declaration",Et.definition="definition",Et.readonly="readonly",Et.static="static",Et.deprecated="deprecated",Et.abstract="abstract",Et.async="async",Et.modification="modification",Et.documentation="documentation",Et.defaultLibrary="defaultLibrary",(Nt||(Nt={})).is=function(e){const t=e;return dn.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(At=Tt||(Tt={})).create=function(e,t){return{range:e,text:t}},At.is=function(e){const t=e;return void 0!==t&&null!==t&&D.is(t.range)&&dn.string(t.text)},(Ot=It||(It={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},Ot.is=function(e){const t=e;return void 0!==t&&null!==t&&D.is(t.range)&&dn.boolean(t.caseSensitiveLookup)&&(dn.string(t.variableName)||void 0===t.variableName)},(Rt=Mt||(Mt={})).create=function(e,t){return{range:e,expression:t}},Rt.is=function(e){const t=e;return void 0!==t&&null!==t&&D.is(t.range)&&(dn.string(t.expression)||void 0===t.expression)},(Bt=Dt||(Dt={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},Bt.is=function(e){const t=e;return dn.defined(t)&&D.is(e.stoppedLocation)},(Pt=Ft||(Ft={})).Type=1,Pt.Parameter=2,Pt.is=function(e){return 1===e||2===e},(zt=Vt||(Vt={})).create=function(e){return{value:e}},zt.is=function(e){const t=e;return dn.objectLiteral(t)&&(void 0===t.tooltip||dn.string(t.tooltip)||Re.is(t.tooltip))&&(void 0===t.location||F.is(t.location))&&(void 0===t.command||oe.is(t.command))},(qt=jt||(jt={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},qt.is=function(e){const t=e;return dn.objectLiteral(t)&&M.is(t.position)&&(dn.string(t.label)||dn.typedArray(t.label,Vt.is))&&(void 0===t.kind||Ft.is(t.kind))&&void 0===t.textEdits||dn.typedArray(t.textEdits,le.is)&&(void 0===t.tooltip||dn.string(t.tooltip)||Re.is(t.tooltip))&&(void 0===t.paddingLeft||dn.boolean(t.paddingLeft))&&(void 0===t.paddingRight||dn.boolean(t.paddingRight))},(Wt||(Wt={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Ut||(Ut={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},($t||($t={})).create=function(e){return{items:e}},(Kt=Ht||(Ht={})).Invoked=0,Kt.Automatic=1,(Gt||(Gt={})).create=function(e,t){return{range:e,text:t}},(Qt||(Qt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(Jt||(Jt={})).is=function(e){const t=e;return dn.objectLiteral(t)&&N.is(t.uri)&&dn.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),s=e.slice(r);t(i,n),t(s,n);let o=0,a=0,l=0;for(;o{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),s=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],o=e.offsetAt(n.range.start),a=e.offsetAt(n.range.end);if(!(a<=s))throw new Error("Overlapping edit");r=r.substring(0,o)+n.newText+r.substring(a,r.length),s=o}return r}}(Xt||(Xt={}));var dn,gn=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return M.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return M.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1e?r=i:n=i+1}let i=n-1;return{line:i,character:e-t[i]}}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1n.line||t.line===n.line&&t.character>n.character?{start:n,end:t}:e}function Sn(e){const t=wn(e.range);return t!==e.range?{newText:e.newText,range:t}:e}function xn(...e){const t=e[0];let n,r,i;if("string"===typeof t)n=t,r=t,e.splice(0,1),i=e&&"object"===typeof e[0]?e[0]:e;else{if(t instanceof Array){const n=e.slice(1);if(t.length!==n.length+1)throw new Error("expected a string as the first argument to l10n.t");let r=t[0];for(let e=1;e0&&(n+=`/${Array.isArray(t.comment)?t.comment.join(""):t.comment}`),i=t.args??{}}return Nn(r,i)}(mn=fn||(fn={})).create=function(e,t,n,r){return new Cn(e,t,n,r)},mn.update=function(e,t,n){if(e instanceof Cn)return e.update(t,n),e;throw new Error("TextDocument.update: document must be created by TextDocument.create")},mn.applyEdits=function(e,t){let n=e.getText(),r=yn(t.map(Sn),((e,t)=>{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),i=0;const s=[];for(const o of r){let t=e.offsetAt(o.range.start);if(ti&&s.push(n.substring(i,t)),o.newText.length&&s.push(o.newText),i=e.offsetAt(o.range.end)}return s.push(n.substr(i)),s.join("")},(bn=pn||(pn={}))[bn.Undefined=0]="Undefined",bn[bn.EnumValueMismatch=1]="EnumValueMismatch",bn[bn.Deprecated=2]="Deprecated",bn[bn.UnexpectedEndOfComment=257]="UnexpectedEndOfComment",bn[bn.UnexpectedEndOfString=258]="UnexpectedEndOfString",bn[bn.UnexpectedEndOfNumber=259]="UnexpectedEndOfNumber",bn[bn.InvalidUnicode=260]="InvalidUnicode",bn[bn.InvalidEscapeCharacter=261]="InvalidEscapeCharacter",bn[bn.InvalidCharacter=262]="InvalidCharacter",bn[bn.PropertyExpected=513]="PropertyExpected",bn[bn.CommaExpected=514]="CommaExpected",bn[bn.ColonExpected=515]="ColonExpected",bn[bn.ValueExpected=516]="ValueExpected",bn[bn.CommaOrCloseBacketExpected=517]="CommaOrCloseBacketExpected",bn[bn.CommaOrCloseBraceExpected=518]="CommaOrCloseBraceExpected",bn[bn.TrailingComma=519]="TrailingComma",bn[bn.DuplicateKey=520]="DuplicateKey",bn[bn.CommentNotPermitted=521]="CommentNotPermitted",bn[bn.PropertyKeysMustBeDoublequoted=528]="PropertyKeysMustBeDoublequoted",bn[bn.SchemaResolveError=768]="SchemaResolveError",bn[bn.SchemaUnsupportedFeature=769]="SchemaUnsupportedFeature",(kn=_n||(_n={}))[kn.v3=3]="v3",kn[kn.v4=4]="v4",kn[kn.v6=6]="v6",kn[kn.v7=7]="v7",kn[kn.v2019_09=19]="v2019_09",kn[kn.v2020_12=20]="v2020_12",(vn||(vn={})).LATEST={textDocument:{completion:{completionItem:{documentationFormat:[Oe.Markdown,Oe.PlainText],commitCharactersSupport:!0,labelDetailsSupport:!0}}}};var En=/{([^}]+)}/g;function Nn(e,t){return 0===Object.keys(t).length?e:e.replace(En,((e,n)=>t[n]??e))}var Tn,An,In={"color-hex":{errorMessage:xn("Invalid color format. Use #RGB, #RGBA, #RRGGBB or #RRGGBBAA."),pattern:/^#([0-9A-Fa-f]{3,4}|([0-9A-Fa-f]{2}){3,4})$/},"date-time":{errorMessage:xn("String is not a RFC3339 date-time."),pattern:/^(\d{4})-(0[1-9]|1[0-2])-(0[1-9]|[12][0-9]|3[01])T([01][0-9]|2[0-3]):([0-5][0-9]):([0-5][0-9]|60)(\.[0-9]+)?(Z|(\+|-)([01][0-9]|2[0-3]):([0-5][0-9]))$/i},date:{errorMessage:xn("String is not a RFC3339 date."),pattern:/^(\d{4})-(0[1-9]|1[0-2])-(0[1-9]|[12][0-9]|3[01])$/i},time:{errorMessage:xn("String is not a RFC3339 time."),pattern:/^([01][0-9]|2[0-3]):([0-5][0-9]):([0-5][0-9]|60)(\.[0-9]+)?(Z|(\+|-)([01][0-9]|2[0-3]):([0-5][0-9]))$/i},email:{errorMessage:xn("String is not an e-mail address."),pattern:/^(([^<>()\[\]\\.,;:\s@"]+(\.[^<>()\[\]\\.,;:\s@"]+)*)|(".+"))@((\[[0-9]{1,3}\.[0-9]{1,3}\.[0-9]{1,3}\.[0-9]{1,3}])|(([a-zA-Z0-9-]+\.)+[a-zA-Z]{2,}))$/},hostname:{errorMessage:xn("String is not a hostname."),pattern:/^(?=.{1,253}\.?$)[a-z0-9](?:[a-z0-9-]{0,61}[a-z0-9])?(?:\.[a-z0-9](?:[-0-9a-z]{0,61}[0-9a-z])?)*\.?$/i},ipv4:{errorMessage:xn("String is not an IPv4 address."),pattern:/^(?:(?:25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)\.){3}(?:25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)$/},ipv6:{errorMessage:xn("String is not an IPv6 address."),pattern:/^((([0-9a-f]{1,4}:){7}([0-9a-f]{1,4}|:))|(([0-9a-f]{1,4}:){6}(:[0-9a-f]{1,4}|((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3})|:))|(([0-9a-f]{1,4}:){5}(((:[0-9a-f]{1,4}){1,2})|:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3})|:))|(([0-9a-f]{1,4}:){4}(((:[0-9a-f]{1,4}){1,3})|((:[0-9a-f]{1,4})?:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(([0-9a-f]{1,4}:){3}(((:[0-9a-f]{1,4}){1,4})|((:[0-9a-f]{1,4}){0,2}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(([0-9a-f]{1,4}:){2}(((:[0-9a-f]{1,4}){1,5})|((:[0-9a-f]{1,4}){0,3}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(([0-9a-f]{1,4}:){1}(((:[0-9a-f]{1,4}){1,6})|((:[0-9a-f]{1,4}){0,4}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:))|(:(((:[0-9a-f]{1,4}){1,7})|((:[0-9a-f]{1,4}){0,5}:((25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)(\.(25[0-5]|2[0-4]\d|1\d\d|[1-9]?\d)){3}))|:)))$/i}},On=class{constructor(e,t,n=0){this.offset=t,this.length=n,this.parent=e}get children(){return[]}toString(){return"type: "+this.type+" ("+this.offset+"/"+this.length+")"+(this.parent?" parent: {"+this.parent.toString()+"}":"")}},Mn=class extends On{constructor(e,t){super(e,t),this.type="null",this.value=null}},Rn=class extends On{constructor(e,t,n){super(e,n),this.type="boolean",this.value=t}},Dn=class extends On{constructor(e,t){super(e,t),this.type="array",this.items=[]}get children(){return this.items}},Bn=class extends On{constructor(e,t){super(e,t),this.type="number",this.isInteger=!0,this.value=Number.NaN}},Fn=class extends On{constructor(e,t,n){super(e,t,n),this.type="string",this.value=""}},Pn=class extends On{constructor(e,t,n){super(e,t),this.type="property",this.colonOffset=-1,this.keyNode=n}get children(){return this.valueNode?[this.keyNode,this.valueNode]:[this.keyNode]}},Vn=class extends On{constructor(e,t){super(e,t),this.type="object",this.properties=[]}get children(){return this.properties}};function zn(e){return on(e)?e?{}:{not:{}}:e}(An=Tn||(Tn={}))[An.Key=0]="Key",An[An.Enum=1]="Enum";var jn={"http://json-schema.org/draft-03/schema#":_n.v3,"http://json-schema.org/draft-04/schema#":_n.v4,"http://json-schema.org/draft-06/schema#":_n.v6,"http://json-schema.org/draft-07/schema#":_n.v7,"https://json-schema.org/draft/2019-09/schema":_n.v2019_09,"https://json-schema.org/draft/2020-12/schema":_n.v2020_12},qn=class{constructor(e){this.schemaDraft=e}},Wn=class e{constructor(e=-1,t){this.focusOffset=e,this.exclude=t,this.schemas=[]}add(e){this.schemas.push(e)}merge(e){Array.prototype.push.apply(this.schemas,e.schemas)}include(e){return(-1===this.focusOffset||Gn(e,this.focusOffset))&&e!==this.exclude}newSub(){return new e(-1,this.exclude)}},Un=class{constructor(){}get schemas(){return[]}add(e){}merge(e){}include(e){return!0}newSub(){return this}};Un.instance=new Un;var $n=class{constructor(){this.problems=[],this.propertiesMatches=0,this.processedProperties=new Set,this.propertiesValueMatches=0,this.primaryValueMatches=0,this.enumValueMatch=!1,this.enumValues=void 0}hasProblems(){return!!this.problems.length}merge(e){this.problems=this.problems.concat(e.problems),this.propertiesMatches+=e.propertiesMatches,this.propertiesValueMatches+=e.propertiesValueMatches,this.mergeProcessedProperties(e)}mergeEnumValues(e){if(!this.enumValueMatch&&!e.enumValueMatch&&this.enumValues&&e.enumValues){this.enumValues=this.enumValues.concat(e.enumValues);for(const e of this.problems)e.code===pn.EnumValueMismatch&&(e.message=xn("Value is not accepted. Valid values: {0}.",this.enumValues.map((e=>JSON.stringify(e))).join(", ")))}}mergePropertyMatch(e){this.problems=this.problems.concat(e.problems),this.propertiesMatches++,(e.enumValueMatch||!e.hasProblems()&&e.propertiesMatches)&&this.propertiesValueMatches++,e.enumValueMatch&&e.enumValues&&1===e.enumValues.length&&this.primaryValueMatches++}mergeProcessedProperties(e){e.processedProperties.forEach((e=>this.processedProperties.add(e)))}compare(e){const t=this.hasProblems();return t!==e.hasProblems()?t?-1:1:this.enumValueMatch!==e.enumValueMatch?e.enumValueMatch?-1:1:this.primaryValueMatches!==e.primaryValueMatches?this.primaryValueMatches-e.primaryValueMatches:this.propertiesValueMatches!==e.propertiesValueMatches?this.propertiesValueMatches-e.propertiesValueMatches:this.propertiesMatches-e.propertiesMatches}};function Hn(e){return tn(e)}function Kn(e){return en(e)}function Gn(e,t,n=!1){return t>=e.offset&&t{let r=e(n);const i=n.children;if(Array.isArray(i))for(let e=0;e{const r=D.create(e.positionAt(t.location.offset),e.positionAt(t.location.offset+t.location.length));return ie.create(r,t.message,t.severity??n,t.code)}))}}getMatchingSchemas(e,t=-1,n){if(this.root&&e){const r=new Wn(t,n),i=Jn(e),s=new qn(i);return Xn(this.root,e,new $n,r,s),r.schemas}return[]}};function Jn(e,t=_n.v2020_12){let n=e.$schema;return n?jn[n]??t:t}function Xn(e,t,n,r,i){if(!e||!r.include(e))return;if("property"===e.type)return Xn(e.valueNode,t,n,r,i);const s=e;switch(function(){function e(e){return s.type===e||"integer"===e&&"number"===s.type&&s.isInteger}Array.isArray(t.type)?t.type.some(e)||n.problems.push({location:{offset:s.offset,length:s.length},message:t.errorMessage||xn("Incorrect type. Expected one of {0}.",t.type.join(", "))}):t.type&&(e(t.type)||n.problems.push({location:{offset:s.offset,length:s.length},message:t.errorMessage||xn('Incorrect type. Expected "{0}".',t.type)}));if(Array.isArray(t.allOf))for(const u of t.allOf){const e=new $n,t=r.newSub();Xn(s,zn(u),e,t,i),n.merge(e),r.merge(t)}const o=zn(t.not);if(o){const e=new $n,a=r.newSub();Xn(s,o,e,a,i),e.hasProblems()||n.problems.push({location:{offset:s.offset,length:s.length},message:t.errorMessage||xn("Matches a schema that is not allowed.")});for(const t of a.schemas)t.inverted=!t.inverted,r.add(t)}const a=(e,t)=>{const o=[];let a;for(const n of e){const e=zn(n),l=new $n,c=r.newSub();if(Xn(s,e,l,c,i),l.hasProblems()||o.push(e),a)if(t||l.hasProblems()||a.validationResult.hasProblems()){const t=l.compare(a.validationResult);t>0?a={schema:e,validationResult:l,matchingSchemas:c}:0===t&&(a.matchingSchemas.merge(c),a.validationResult.mergeEnumValues(l))}else a.matchingSchemas.merge(c),a.validationResult.propertiesMatches+=l.propertiesMatches,a.validationResult.propertiesValueMatches+=l.propertiesValueMatches,a.validationResult.mergeProcessedProperties(l);else a={schema:e,validationResult:l,matchingSchemas:c}}return o.length>1&&t&&n.problems.push({location:{offset:s.offset,length:1},message:xn("Matches multiple schemas when only one must validate.")}),a&&(n.merge(a.validationResult),r.merge(a.matchingSchemas)),o.length};Array.isArray(t.anyOf)&&a(t.anyOf,!1);Array.isArray(t.oneOf)&&a(t.oneOf,!0);const l=e=>{const t=new $n,o=r.newSub();Xn(s,zn(e),t,o,i),n.merge(t),r.merge(o)},c=zn(t.if);c&&((e,t,o)=>{const a=zn(e),c=new $n,h=r.newSub();Xn(s,a,c,h,i),r.merge(h),n.mergeProcessedProperties(c),c.hasProblems()?o&&l(o):t&&l(t)})(c,zn(t.then),zn(t.else));if(Array.isArray(t.enum)){const e=Hn(s);let r=!1;for(const n of t.enum)if(nn(e,n)){r=!0;break}n.enumValues=t.enum,n.enumValueMatch=r,r||n.problems.push({location:{offset:s.offset,length:s.length},code:pn.EnumValueMismatch,message:t.errorMessage||xn("Value is not accepted. Valid values: {0}.",t.enum.map((e=>JSON.stringify(e))).join(", "))})}if(sn(t.const)){nn(Hn(s),t.const)?n.enumValueMatch=!0:(n.problems.push({location:{offset:s.offset,length:s.length},code:pn.EnumValueMismatch,message:t.errorMessage||xn("Value must be {0}.",JSON.stringify(t.const))}),n.enumValueMatch=!1),n.enumValues=[t.const]}let h=t.deprecationMessage;if(h||t.deprecated){h=h||xn("Value is deprecated");let e="property"===s.parent?.type?s.parent:s;n.problems.push({location:{offset:e.offset,length:e.length},severity:Z.Warning,message:h,code:pn.Deprecated})}}(),s.type){case"object":!function(e){const s=Object.create(null),o=new Set;for(const t of e.properties){const e=t.keyNode.value;s[e]=t.valueNode,o.add(e)}if(Array.isArray(t.required))for(const r of t.required)if(!s[r]){const t=e.parent&&"property"===e.parent.type&&e.parent.keyNode,i=t?{offset:t.offset,length:t.length}:{offset:e.offset,length:1};n.problems.push({location:i,message:xn('Missing property "{0}".',r)})}const a=e=>{o.delete(e),n.processedProperties.add(e)};if(t.properties)for(const d of Object.keys(t.properties)){a(d);const e=t.properties[d],o=s[d];if(o)if(on(e))if(e)n.propertiesMatches++,n.propertiesValueMatches++;else{const e=o.parent;n.problems.push({location:{offset:e.keyNode.offset,length:e.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",d)})}else{const t=new $n;Xn(o,e,t,r,i),n.mergePropertyMatch(t)}}if(t.patternProperties)for(const d of Object.keys(t.patternProperties)){const e=hn(d);if(e){const l=[];for(const a of o)if(e.test(a)){l.push(a);const e=s[a];if(e){const s=t.patternProperties[d];if(on(s))if(s)n.propertiesMatches++,n.propertiesValueMatches++;else{const r=e.parent;n.problems.push({location:{offset:r.keyNode.offset,length:r.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",a)})}else{const t=new $n;Xn(e,s,t,r,i),n.mergePropertyMatch(t)}}}l.forEach(a)}}const l=t.additionalProperties;if(void 0!==l)for(const d of o){a(d);const e=s[d];if(e)if(!1===l){const r=e.parent;n.problems.push({location:{offset:r.keyNode.offset,length:r.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",d)})}else if(!0!==l){const t=new $n;Xn(e,l,t,r,i),n.mergePropertyMatch(t)}}const c=t.unevaluatedProperties;if(void 0!==c){const e=[];for(const a of o)if(!n.processedProperties.has(a)){e.push(a);const o=s[a];if(o)if(!1===c){const e=o.parent;n.problems.push({location:{offset:e.keyNode.offset,length:e.keyNode.length},message:t.errorMessage||xn("Property {0} is not allowed.",a)})}else if(!0!==c){const e=new $n;Xn(o,c,e,r,i),n.mergePropertyMatch(e)}}e.forEach(a)}rn(t.maxProperties)&&e.properties.length>t.maxProperties&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Object has more properties than limit of {0}.",t.maxProperties)});rn(t.minProperties)&&e.properties.length=_n.v2020_12?(s=t.prefixItems,o=Array.isArray(t.items)?void 0:t.items):(s=Array.isArray(t.items)?t.items:void 0,o=Array.isArray(t.items)?t.additionalItems:t.items);let a=0;if(void 0!==s){const t=Math.min(s.length,e.items.length);for(;a=_n.v2020_12&&n.processedProperties.add(String(t)))}0!==r||rn(t.minContains)||n.problems.push({location:{offset:e.offset,length:e.length},message:t.errorMessage||xn("Array does not contain required item.")}),rn(t.minContains)&&rt.maxContains&&n.problems.push({location:{offset:e.offset,length:e.length},message:t.errorMessage||xn("Array has too many items that match the contains contraint. Expected {0} or less.",t.maxContains)})}const c=t.unevaluatedItems;if(void 0!==c)for(let h=0;ht.maxItems&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Array has too many items. Expected {0} or fewer.",t.maxItems)});if(!0===t.uniqueItems){let t=function(){for(let e=0;et.maxLength&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("String is longer than the maximum length of {0}.",t.maxLength)});if(an(t.pattern)){const r=hn(t.pattern);r?.test(e.value)||n.problems.push({location:{offset:e.offset,length:e.length},message:t.patternErrorMessage||t.errorMessage||xn('String does not match the pattern of "{0}".',t.pattern)})}if(t.format)switch(t.format){case"uri":case"uri-reference":{let r;if(e.value){const n=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/.exec(e.value);n?n[2]||"uri"!==t.format||(r=xn("URI with a scheme is expected.")):r=xn("URI is expected.")}else r=xn("URI expected.");r&&n.problems.push({location:{offset:e.offset,length:e.length},message:t.patternErrorMessage||t.errorMessage||xn("String is not a URI: {0}",r)})}break;case"color-hex":case"date-time":case"date":case"time":case"email":case"hostname":case"ipv4":case"ipv6":const r=In[t.format];e.value&&r.pattern.exec(e.value)||n.problems.push({location:{offset:e.offset,length:e.length},message:t.patternErrorMessage||t.errorMessage||r.errorMessage})}}(s);break;case"number":!function(e){const r=e.value;function i(e){const t=/^(-?\d+)(?:\.(\d+))?(?:e([-+]\d+))?$/.exec(e.toString());return t&&{value:Number(t[1]+(t[2]||"")),multiplier:(t[2]?.length||0)-(parseInt(t[3])||0)}}if(rn(t.multipleOf)){let s=-1;if(Number.isInteger(t.multipleOf))s=r%t.multipleOf;else{let e=i(t.multipleOf),n=i(r);if(e&&n){const t=10**Math.abs(n.multiplier-e.multiplier);n.multiplier=l&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Value is above the exclusive maximum of {0}.",l)});const c=o(t.minimum,t.exclusiveMinimum);rn(c)&&rh&&n.problems.push({location:{offset:e.offset,length:e.length},message:xn("Value is above the maximum of {0}.",h)})}(s)}r.add({node:s,schema:t})}function Yn(e,t){const n=[];let r=-1;const i=e.getText(),s=w(i,!1),o=t&&t.collectComments?[]:void 0;function a(){for(;;){const t=s.scan();switch(h(),t){case 12:case 13:Array.isArray(o)&&o.push(D.create(e.positionAt(s.getTokenOffset()),e.positionAt(s.getTokenOffset()+s.getTokenLength())));break;case 15:case 14:break;default:return t}}}function l(t,i,s,o,a=Z.Error){if(0===n.length||s!==r){const l=D.create(e.positionAt(s),e.positionAt(o));n.push(ie.create(l,t,a,i,e.languageId)),r=s}}function c(e,t,n=void 0,r=[],o=[]){let c=s.getTokenOffset(),h=s.getTokenOffset()+s.getTokenLength();if(c===h&&c>0){for(c--;c>0&&/\s/.test(i.charAt(c));)c--;h=c+1}if(l(e,t,c,h),n&&u(n,!1),r.length+o.length>0){let e=s.getToken();for(;17!==e;){if(-1!==r.indexOf(e)){a();break}if(-1!==o.indexOf(e))break;e=a()}}return n}function h(){switch(s.getTokenError()){case 4:return c(xn("Invalid unicode sequence in string."),pn.InvalidUnicode),!0;case 5:return c(xn("Invalid escape character in string."),pn.InvalidEscapeCharacter),!0;case 3:return c(xn("Unexpected end of number."),pn.UnexpectedEndOfNumber),!0;case 1:return c(xn("Unexpected end of comment."),pn.UnexpectedEndOfComment),!0;case 2:return c(xn("Unexpected end of string."),pn.UnexpectedEndOfString),!0;case 6:return c(xn("Invalid characters in string. Control characters must be escaped."),pn.InvalidCharacter),!0}return!1}function u(e,t){return e.length=s.getTokenOffset()+s.getTokenLength()-e.offset,t&&a(),e}const d=new Fn(void 0,0,0);function g(t,n){const r=new Pn(t,s.getTokenOffset(),d);let i=f(r);if(!i){if(16!==s.getToken())return;{c(xn("Property keys must be doublequoted"),pn.PropertyKeysMustBeDoublequoted);const e=new Fn(r,s.getTokenOffset(),s.getTokenLength());e.value=s.getTokenValue(),i=e,a()}}if(r.keyNode=i,"//"!==i.value){const e=n[i.value];e?(l(xn("Duplicate object key"),pn.DuplicateKey,r.keyNode.offset,r.keyNode.offset+r.keyNode.length,Z.Warning),ln(e)&&l(xn("Duplicate object key"),pn.DuplicateKey,e.keyNode.offset,e.keyNode.offset+e.keyNode.length,Z.Warning),n[i.value]=!0):n[i.value]=r}if(6===s.getToken())r.colonOffset=s.getTokenOffset(),a();else if(c(xn("Colon expected"),pn.ColonExpected),10===s.getToken()&&e.positionAt(i.offset+i.length).line=0;t--){const n=this.contributions[t].resolveCompletion;if(n){const t=n(e);if(t)return t}}return this.promiseConstructor.resolve(e)}doComplete(e,t,n){const r={items:[],isIncomplete:!1},i=e.getText(),s=e.offsetAt(t);let o=n.getNodeFromOffset(s,!0);if(this.isInComment(e,o?o.offset:0,s))return Promise.resolve(r);if(o&&s===o.offset+o.length&&s>0){const e=i[s-1];("object"===o.type&&"}"===e||"array"===o.type&&"]"===e)&&(o=o.parent)}const a=this.getCurrentWord(e,s);let l;if(!o||"string"!==o.type&&"number"!==o.type&&"boolean"!==o.type&&"null"!==o.type){let n=s-a.length;n>0&&'"'===i[n-1]&&n--,l=D.create(e.positionAt(n),t)}else l=D.create(e.positionAt(o.offset),e.positionAt(o.offset+o.length));const c=new Map,h={add:e=>{let t=e.label;const n=c.get(t);if(n)n.documentation||(n.documentation=e.documentation),n.detail||(n.detail=e.detail),n.labelDetails||(n.labelDetails=e.labelDetails);else{if(t=t.replace(/[\n]/g,"\u21b5"),t.length>60){const e=t.substr(0,57).trim()+"...";c.has(e)||(t=e)}e.textEdit=le.replace(l,e.insertText),e.label=t,c.set(t,e),r.items.push(e)}},setAsIncomplete:()=>{r.isIncomplete=!0},error:e=>{console.error(e)},getNumberOfProposals:()=>r.items.length};return this.schemaService.getSchemaForResource(e.uri,n).then((t=>{const u=[];let d,g=!0,f="";if(o&&"string"===o.type){const e=o.parent;e&&"property"===e.type&&e.keyNode===o&&(g=!e.valueNode,d=e,f=i.substr(o.offset+1,o.length-2),e&&(o=e.parent))}if(o&&"object"===o.type){if(o.offset===s)return r;o.properties.forEach((e=>{d&&d===e||c.set(e.keyNode.value,$e.create("__"))}));let m="";g&&(m=this.evaluateSeparatorAfter(e,e.offsetAt(l.end))),t?this.getPropertyCompletions(t,n,o,g,m,h):this.getSchemaLessPropertyCompletions(n,o,f,h);const p=Kn(o);this.contributions.forEach((t=>{const n=t.collectPropertyCompletions(e.uri,p,a,g,""===m,h);n&&u.push(n)})),!t&&a.length>0&&'"'!==i.charAt(s-a.length-1)&&(h.add({kind:De.Property,label:this.getLabelForValue(a),insertText:this.getInsertTextForProperty(a,void 0,!1,m),insertTextFormat:Fe.Snippet,documentation:""}),h.setAsIncomplete())}const m={};return t?this.getValueCompletions(t,n,o,s,e,h,m):this.getSchemaLessValueCompletions(n,o,s,e,h),this.contributions.length>0&&this.getContributedValueCompletions(n,o,s,e,h,u),this.promiseConstructor.all(u).then((()=>{if(0===h.getNumberOfProposals()){let t=s;!o||"string"!==o.type&&"number"!==o.type&&"boolean"!==o.type&&"null"!==o.type||(t=o.offset+o.length);const n=this.evaluateSeparatorAfter(e,t);this.addFillerValueCompletions(m,n,h)}return r}))}))}getPropertyCompletions(e,t,n,r,i,s){t.getMatchingSchemas(e.schema,n.offset).forEach((e=>{if(e.node===n&&!e.inverted){const t=e.schema.properties;t&&Object.keys(t).forEach((e=>{const n=t[e];if("object"===typeof n&&!n.deprecationMessage&&!n.doNotSuggest){const t={kind:De.Property,label:e,insertText:this.getInsertTextForProperty(e,n,r,i),insertTextFormat:Fe.Snippet,filterText:this.getFilterTextForValue(e),documentation:this.fromMarkup(n.markdownDescription)||n.description||""};void 0!==n.suggestSortText&&(t.sortText=n.suggestSortText),t.insertText&&cn(t.insertText,`$1${i}`)&&(t.command={title:"Suggest",command:"editor.action.triggerSuggest"}),s.add(t)}}));const n=e.schema.propertyNames;if("object"===typeof n&&!n.deprecationMessage&&!n.doNotSuggest){const e=(e,t=void 0)=>{const o={kind:De.Property,label:e,insertText:this.getInsertTextForProperty(e,void 0,r,i),insertTextFormat:Fe.Snippet,filterText:this.getFilterTextForValue(e),documentation:t||this.fromMarkup(n.markdownDescription)||n.description||""};void 0!==n.suggestSortText&&(o.sortText=n.suggestSortText),o.insertText&&cn(o.insertText,`$1${i}`)&&(o.command={title:"Suggest",command:"editor.action.triggerSuggest"}),s.add(o)};if(n.enum)for(let t=0;t{e.properties.forEach((e=>{const t=e.keyNode.value;r.add({kind:De.Property,label:t,insertText:this.getInsertTextForValue(t,""),insertTextFormat:Fe.Snippet,filterText:this.getFilterTextForValue(t),documentation:""})}))};if(t.parent)if("property"===t.parent.type){const n=t.parent.keyNode.value;e.visit((e=>("property"===e.type&&e!==t.parent&&e.keyNode.value===n&&e.valueNode&&"object"===e.valueNode.type&&i(e.valueNode),!0)))}else"array"===t.parent.type&&t.parent.items.forEach((e=>{"object"===e.type&&e!==t&&i(e)}));else"object"===t.type&&r.add({kind:De.Property,label:"$schema",insertText:this.getInsertTextForProperty("$schema",void 0,!0,""),insertTextFormat:Fe.Snippet,documentation:"",filterText:this.getFilterTextForValue("$schema")})}getSchemaLessValueCompletions(e,t,n,r,i){let s=n;if(!t||"string"!==t.type&&"number"!==t.type&&"boolean"!==t.type&&"null"!==t.type||(s=t.offset+t.length,t=t.parent),!t)return i.add({kind:this.getSuggestionKind("object"),label:"Empty object",insertText:this.getInsertTextForValue({},""),insertTextFormat:Fe.Snippet,documentation:""}),void i.add({kind:this.getSuggestionKind("array"),label:"Empty array",insertText:this.getInsertTextForValue([],""),insertTextFormat:Fe.Snippet,documentation:""});const o=this.evaluateSeparatorAfter(r,s),a=e=>{e.parent&&!Gn(e.parent,n,!0)&&i.add({kind:this.getSuggestionKind(e.type),label:this.getLabelTextForMatchingNode(e,r),insertText:this.getInsertTextForMatchingNode(e,r,o),insertTextFormat:Fe.Snippet,documentation:""}),"boolean"===e.type&&this.addBooleanValueCompletion(!e.value,o,i)};if("property"===t.type&&n>(t.colonOffset||0)){const r=t.valueNode;if(r&&(n>r.offset+r.length||"object"===r.type||"array"===r.type))return;const s=t.keyNode.value;e.visit((e=>("property"===e.type&&e.keyNode.value===s&&e.valueNode&&a(e.valueNode),!0))),"$schema"===s&&t.parent&&!t.parent.parent&&this.addDollarSchemaCompletions(o,i)}if("array"===t.type)if(t.parent&&"property"===t.parent.type){const n=t.parent.keyNode.value;e.visit((e=>("property"===e.type&&e.keyNode.value===n&&e.valueNode&&"array"===e.valueNode.type&&e.valueNode.items.forEach(a),!0)))}else t.items.forEach(a)}getValueCompletions(e,t,n,r,i,s,o){let a,l,c=r;if(!n||"string"!==n.type&&"number"!==n.type&&"boolean"!==n.type&&"null"!==n.type||(c=n.offset+n.length,l=n,n=n.parent),n){if("property"===n.type&&r>(n.colonOffset||0)){const e=n.valueNode;if(e&&r>e.offset+e.length)return;a=n.keyNode.value,n=n.parent}if(n&&(void 0!==a||"array"===n.type)){const h=this.evaluateSeparatorAfter(i,c),u=t.getMatchingSchemas(e.schema,n.offset,l);for(const e of u)if(e.node===n&&!e.inverted&&e.schema){if("array"===n.type&&e.schema.items){let t=s;if(e.schema.uniqueItems){const e=new Set;n.children.forEach((t=>{"array"!==t.type&&"object"!==t.type&&e.add(this.getLabelForValue(Hn(t)))})),t={...s,add(t){e.has(t.label)||s.add(t)}}}if(Array.isArray(e.schema.items)){const s=this.findItemAtOffset(n,i,r);s(t.colonOffset||0)){const e=t.keyNode.value,o=t.valueNode;if((!o||n<=o.offset+o.length)&&t.parent){const n=Kn(t.parent);this.contributions.forEach((t=>{const o=t.collectValueCompletions(r.uri,n,e,i);o&&s.push(o)}))}}}else this.contributions.forEach((e=>{const t=e.collectDefaultCompletions(r.uri,i);t&&s.push(t)}))}addSchemaValueCompletions(e,t,n,r){"object"===typeof e&&(this.addEnumValueCompletions(e,t,n),this.addDefaultValueCompletions(e,t,n),this.collectTypes(e,r),Array.isArray(e.allOf)&&e.allOf.forEach((e=>this.addSchemaValueCompletions(e,t,n,r))),Array.isArray(e.anyOf)&&e.anyOf.forEach((e=>this.addSchemaValueCompletions(e,t,n,r))),Array.isArray(e.oneOf)&&e.oneOf.forEach((e=>this.addSchemaValueCompletions(e,t,n,r))))}addDefaultValueCompletions(e,t,n,r=0){let i=!1;if(sn(e.default)){let s=e.type,o=e.default;for(let e=r;e>0;e--)o=[o],s="array";const a={kind:this.getSuggestionKind(s),label:this.getLabelForValue(o),insertText:this.getInsertTextForValue(o,t),insertTextFormat:Fe.Snippet};this.doesSupportsLabelDetails()?a.labelDetails={description:xn("Default value")}:a.detail=xn("Default value"),n.add(a),i=!0}Array.isArray(e.examples)&&e.examples.forEach((s=>{let o=e.type,a=s;for(let e=r;e>0;e--)a=[a],o="array";n.add({kind:this.getSuggestionKind(o),label:this.getLabelForValue(a),insertText:this.getInsertTextForValue(a,t),insertTextFormat:Fe.Snippet}),i=!0})),Array.isArray(e.defaultSnippets)&&e.defaultSnippets.forEach((s=>{let o,a,l=e.type,c=s.body,h=s.label;if(sn(c)){let n=e.type;for(let e=r;e>0;e--)c=[c],n="array";o=this.getInsertTextForSnippetValue(c,t),a=this.getFilterTextForSnippetValue(c),h=h||this.getLabelForSnippetValue(c)}else{if("string"!==typeof s.bodyText)return;{let e="",n="",i="";for(let t=r;t>0;t--)e=e+i+"[\n",n=n+"\n"+i+"]",i+="\t",l="array";o=e+i+s.bodyText.split("\n").join("\n"+i)+n+t,h=h||o,a=o.replace(/[\n]/g,"")}}n.add({kind:this.getSuggestionKind(l),label:h,documentation:this.fromMarkup(s.markdownDescription)||s.description,insertText:o,insertTextFormat:Fe.Snippet,filterText:a}),i=!0})),!i&&"object"===typeof e.items&&!Array.isArray(e.items)&&r<5&&this.addDefaultValueCompletions(e.items,t,n,r+1)}addEnumValueCompletions(e,t,n){if(sn(e.const)&&n.add({kind:this.getSuggestionKind(e.type),label:this.getLabelForValue(e.const),insertText:this.getInsertTextForValue(e.const,t),insertTextFormat:Fe.Snippet,documentation:this.fromMarkup(e.markdownDescription)||e.description}),Array.isArray(e.enum))for(let r=0,i=e.enum.length;rt[e]=!0)):n&&(t[n]=!0)}addFillerValueCompletions(e,t,n){e.object&&n.add({kind:this.getSuggestionKind("object"),label:"{}",insertText:this.getInsertTextForGuessedValue({},t),insertTextFormat:Fe.Snippet,detail:xn("New object"),documentation:""}),e.array&&n.add({kind:this.getSuggestionKind("array"),label:"[]",insertText:this.getInsertTextForGuessedValue([],t),insertTextFormat:Fe.Snippet,detail:xn("New array"),documentation:""})}addBooleanValueCompletion(e,t,n){n.add({kind:this.getSuggestionKind("boolean"),label:e?"true":"false",insertText:this.getInsertTextForValue(e,t),insertTextFormat:Fe.Snippet,documentation:""})}addNullValueCompletion(e,t){t.add({kind:this.getSuggestionKind("null"),label:"null",insertText:"null"+e,insertTextFormat:Fe.Snippet,documentation:""})}addDollarSchemaCompletions(e,t){this.schemaService.getRegisteredSchemaIds((e=>"http"===e||"https"===e)).forEach((n=>{n.startsWith("http://json-schema.org/draft-")&&(n+="#"),t.add({kind:De.Module,label:this.getLabelForValue(n),filterText:this.getFilterTextForValue(n),insertText:this.getInsertTextForValue(n,e),insertTextFormat:Fe.Snippet,documentation:""})}))}getLabelForValue(e){return JSON.stringify(e)}getValueFromLabel(e){return JSON.parse(e)}getFilterTextForValue(e){return JSON.stringify(e)}getFilterTextForSnippetValue(e){return JSON.stringify(e).replace(/\$\{\d+:([^}]+)\}|\$\d+/g,"$1")}getLabelForSnippetValue(e){return JSON.stringify(e).replace(/\$\{\d+:([^}]+)\}|\$\d+/g,"$1")}getInsertTextForPlainText(e){return e.replace(/[\\\$\}]/g,"\\$&")}getInsertTextForValue(e,t){const n=JSON.stringify(e,null,"\t");return"{}"===n?"{$1}"+t:"[]"===n?"[$1]"+t:this.getInsertTextForPlainText(n+t)}getInsertTextForSnippetValue(e,t){return Zn(e,"",(e=>"string"===typeof e&&"^"===e[0]?e.substr(1):JSON.stringify(e)))+t}getInsertTextForGuessedValue(e,t){switch(typeof e){case"object":return null===e?"${1:null}"+t:this.getInsertTextForValue(e,t);case"string":let n=JSON.stringify(e);return n=n.substr(1,n.length-2),n=this.getInsertTextForPlainText(n),'"${1:'+n+'}"'+t;case"number":case"boolean":return"${1:"+JSON.stringify(e)+"}"+t}return this.getInsertTextForValue(e,t)}getSuggestionKind(e){if(Array.isArray(e)){const t=e;e=t.length>0?t[0]:void 0}if(!e)return De.Value;switch(e){case"string":default:return De.Value;case"object":return De.Module;case"property":return De.Property}}getLabelTextForMatchingNode(e,t){switch(e.type){case"array":return"[]";case"object":return"{}";default:return t.getText().substr(e.offset,e.length)}}getInsertTextForMatchingNode(e,t,n){switch(e.type){case"array":return this.getInsertTextForValue([],n);case"object":return this.getInsertTextForValue({},n);default:const r=t.getText().substr(e.offset,e.length)+n;return this.getInsertTextForPlainText(r)}}getInsertTextForProperty(e,t,n,r){const i=this.getInsertTextForValue(e,"");if(!n)return i;const s=i+": ";let o,a=0;if(t){if(Array.isArray(t.defaultSnippets)){if(1===t.defaultSnippets.length){const e=t.defaultSnippets[0].body;sn(e)&&(o=this.getInsertTextForSnippetValue(e,""))}a+=t.defaultSnippets.length}if(t.enum&&(o||1!==t.enum.length||(o=this.getInsertTextForGuessedValue(t.enum[0],"")),a+=t.enum.length),sn(t.const)&&(o||(o=this.getInsertTextForGuessedValue(t.const,"")),a++),sn(t.default)&&(o||(o=this.getInsertTextForGuessedValue(t.default,"")),a++),Array.isArray(t.examples)&&t.examples.length&&(o||(o=this.getInsertTextForGuessedValue(t.examples[0],"")),a+=t.examples.length),0===a){let e=Array.isArray(t.type)?t.type[0]:t.type;switch(e||(t.properties?e="object":t.items&&(e="array")),e){case"boolean":o="$1";break;case"string":o='"$1"';break;case"object":o="{$1}";break;case"array":o="[$1]";break;case"number":case"integer":o="${1:0}";break;case"null":o="${1:null}";break;default:return i}}}return(!o||a>1)&&(o="$1"),s+o+r}getCurrentWord(e,t){let n=t-1;const r=e.getText();for(;n>=0&&-1===' \t\n\r\v":{[,]}'.indexOf(r.charAt(n));)n--;return r.substring(n+1,t)}evaluateSeparatorAfter(e,t){const n=w(e.getText(),!0);n.setPosition(t);switch(n.scan()){case 5:case 2:case 4:case 17:return"";default:return","}}findItemAtOffset(e,t,n){const r=w(t.getText(),!0),i=e.items;for(let s=i.length-1;s>=0;s--){const e=i[s];if(n>e.offset+e.length){r.setPosition(e.offset+e.length);return 5===r.scan()&&n>=r.getTokenOffset()+r.getTokenLength()?s+1:s}if(n>=e.offset)return s}return 0}isInComment(e,t,n){const r=w(e.getText(),!1);r.setPosition(t);let i=r.scan();for(;17!==i&&r.getTokenOffset()+r.getTokenLength()i.offset+1&&r({contents:e,range:o}),l=Kn(i);for(let c=this.contributions.length-1;c>=0;c--){const t=this.contributions[c].getInfoContribution(e.uri,l);if(t)return t.then((e=>a(e)))}return this.schemaService.getSchemaForResource(e.uri,n).then((e=>{if(e&&i){let t,r,s,o;n.getMatchingSchemas(e.schema,i.offset).every((e=>{if(e.node===i&&!e.inverted&&e.schema&&(t=t||e.schema.title,r=r||e.schema.markdownDescription||nr(e.schema.description),e.schema.enum)){const t=e.schema.enum.indexOf(Hn(i));e.schema.markdownEnumDescriptions?s=e.schema.markdownEnumDescriptions[t]:e.schema.enumDescriptions&&(s=nr(e.schema.enumDescriptions[t])),s&&(o=e.schema.enum[t],"string"!==typeof o&&(o=JSON.stringify(o)))}return!0}));let l="";return t&&(l=nr(t)),r&&(l.length>0&&(l+="\n\n"),l+=r),s&&(l.length>0&&(l+="\n\n"),l+=`\`${function(e){if(-1!==e.indexOf("`"))return"`` "+e+" ``";return e}(o)}\`: ${s}`),a([l])}return null}))}};function nr(e){if(e){return e.replace(/([^\n\r])(\r?\n)([^\n\r])/gm,"$1\n\n$3").replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}}var rr=class{constructor(e,t){this.jsonSchemaService=e,this.promise=t,this.validationEnabled=!0}configure(e){e&&(this.validationEnabled=!1!==e.validate,this.commentSeverity=e.allowComments?void 0:Z.Error)}doValidation(e,t,n,r){if(!this.validationEnabled)return this.promise.resolve([]);const i=[],s={},o=e=>{const t=e.range.start.line+" "+e.range.start.character+" "+e.message;s[t]||(s[t]=!0,i.push(e))},a=r=>{let s=n?.trailingCommas?ar(n.trailingCommas):Z.Error,a=n?.comments?ar(n.comments):this.commentSeverity,l=n?.schemaValidation?ar(n.schemaValidation):Z.Warning,c=n?.schemaRequest?ar(n.schemaRequest):Z.Warning;if(r){const i=(n,r)=>{if(t.root&&c){const i=t.root,s="object"===i.type?i.properties[0]:void 0;if(s&&"$schema"===s.keyNode.value){const t=s.valueNode||s,i=D.create(e.positionAt(t.offset),e.positionAt(t.offset+t.length));o(ie.create(i,n,c,r))}else{const t=D.create(e.positionAt(i.offset),e.positionAt(i.offset+1));o(ie.create(t,n,c,r))}}};if(r.errors.length)i(r.errors[0],pn.SchemaResolveError);else if(l){for(const e of r.warnings)i(e,pn.SchemaUnsupportedFeature);const s=t.validate(e,r.schema,l,n?.schemaDraft);s&&s.forEach(o)}sr(r.schema)&&(a=void 0),or(r.schema)&&(s=void 0)}for(const e of t.syntaxErrors){if(e.code===pn.TrailingComma){if("number"!==typeof s)continue;e.severity=s}o(e)}if("number"===typeof a){const e=xn("Comments are not permitted in JSON.");t.comments.forEach((t=>{o(ie.create(t,e,a,pn.CommentNotPermitted))}))}return i};if(r){const e=r.id||"schemaservice://untitled/"+ir++;return this.jsonSchemaService.registerExternalSchema({uri:e,schema:r}).getResolvedSchema().then((e=>a(e)))}return this.jsonSchemaService.getSchemaForResource(e.uri,t).then((e=>a(e)))}getLanguageStatus(e,t){return{schemas:this.jsonSchemaService.getSchemaURIsForResource(e.uri,t)}}},ir=0;function sr(e){if(e&&"object"===typeof e){if(on(e.allowComments))return e.allowComments;if(e.allOf)for(const t of e.allOf){const e=sr(t);if(on(e))return e}}}function or(e){if(e&&"object"===typeof e){if(on(e.allowTrailingCommas))return e.allowTrailingCommas;const t=e;if(on(t.allowsTrailingCommas))return t.allowsTrailingCommas;if(e.allOf)for(const n of e.allOf){const e=or(n);if(on(e))return e}}}function ar(e){switch(e){case"error":return Z.Error;case"warning":return Z.Warning;case"ignore":return}}function lr(e){return e<48?0:e<=57?e-48:(e<97&&(e+=32),e>=97&&e<=102?e-97+10:0)}function cr(e){if("#"===e[0])switch(e.length){case 4:return{red:17*lr(e.charCodeAt(1))/255,green:17*lr(e.charCodeAt(2))/255,blue:17*lr(e.charCodeAt(3))/255,alpha:1};case 5:return{red:17*lr(e.charCodeAt(1))/255,green:17*lr(e.charCodeAt(2))/255,blue:17*lr(e.charCodeAt(3))/255,alpha:17*lr(e.charCodeAt(4))/255};case 7:return{red:(16*lr(e.charCodeAt(1))+lr(e.charCodeAt(2)))/255,green:(16*lr(e.charCodeAt(3))+lr(e.charCodeAt(4)))/255,blue:(16*lr(e.charCodeAt(5))+lr(e.charCodeAt(6)))/255,alpha:1};case 9:return{red:(16*lr(e.charCodeAt(1))+lr(e.charCodeAt(2)))/255,green:(16*lr(e.charCodeAt(3))+lr(e.charCodeAt(4)))/255,blue:(16*lr(e.charCodeAt(5))+lr(e.charCodeAt(6)))/255,alpha:(16*lr(e.charCodeAt(7))+lr(e.charCodeAt(8)))/255}}}var hr=class{constructor(e){this.schemaService=e}findDocumentSymbols(e,t,n={resultLimit:Number.MAX_VALUE}){const r=t.root;if(!r)return[];let i=n.resultLimit||Number.MAX_VALUE;const s=e.uri;if(("vscode://defaultsettings/keybindings.json"===s||cn(s.toLowerCase(),"/user/keybindings.json"))&&"array"===r.type){const t=[];for(const o of r.items)if("object"===o.type)for(const r of o.properties)if("key"===r.keyNode.value&&r.valueNode){const a=F.create(e.uri,ur(e,o));if(t.push({name:dr(r.valueNode),kind:tt.Function,location:a}),i--,i<=0)return n&&n.onResultLimitExceeded&&n.onResultLimitExceeded(s),t}return t}const o=[{node:r,containerName:""}];let a=0,l=!1;const c=[],h=(t,n)=>{"array"===t.type?t.items.forEach((e=>{e&&o.push({node:e,containerName:n})})):"object"===t.type&&t.properties.forEach((t=>{const r=t.valueNode;if(r)if(i>0){i--;const s=F.create(e.uri,ur(e,t)),a=n?n+"."+t.keyNode.value:t.keyNode.value;c.push({name:this.getKeyLabel(t),kind:this.getSymbolKind(r.type),location:s,containerName:n}),o.push({node:r,containerName:a})}else l=!0}))};for(;a{"array"===t.type?t.items.forEach(((t,r)=>{if(t)if(i>0){i--;const s=ur(e,t),o=s,l={name:String(r),kind:this.getSymbolKind(t.type),range:s,selectionRange:o,children:[]};n.push(l),a.push({result:l.children,node:t})}else c=!0})):"object"===t.type&&t.properties.forEach((t=>{const r=t.valueNode;if(r)if(i>0){i--;const s=ur(e,t),o=ur(e,t.keyNode),l=[],c={name:this.getKeyLabel(t),kind:this.getSymbolKind(r.type),range:s,selectionRange:o,children:l,detail:this.getDetail(r)};n.push(c),a.push({result:l,node:r})}else c=!0}))};for(;l{const i=[];if(r){let s=n&&"number"===typeof n.resultLimit?n.resultLimit:Number.MAX_VALUE;const o=t.getMatchingSchemas(r.schema),a={};for(const t of o)if(!t.inverted&&t.schema&&("color"===t.schema.format||"color-hex"===t.schema.format)&&t.node&&"string"===t.node.type){const r=String(t.node.offset);if(!a[r]){const o=cr(Hn(t.node));if(o){const n=ur(e,t.node);i.push({color:o,range:n})}if(a[r]=!0,s--,s<=0)return n&&n.onResultLimitExceeded&&n.onResultLimitExceeded(e.uri),i}}}return i}))}getColorPresentations(e,t,n,r){const i=[],s=Math.round(255*n.red),o=Math.round(255*n.green),a=Math.round(255*n.blue);function l(e){const t=e.toString(16);return 2!==t.length?"0"+t:t}let c;return c=1===n.alpha?`#${l(s)}${l(o)}${l(a)}`:`#${l(s)}${l(o)}${l(a)}${l(Math.round(255*n.alpha))}`,i.push({label:c,textEdit:le.replace(r,JSON.stringify(c))}),i}};function ur(e,t){return D.create(e.positionAt(t.offset),e.positionAt(t.offset+t.length))}function dr(e){return Hn(e)||xn("")}var gr,fr={schemaAssociations:[],schemas:{"http://json-schema.org/draft-04/schema#":{$schema:"http://json-schema.org/draft-04/schema#",definitions:{schemaArray:{type:"array",minItems:1,items:{$ref:"#"}},positiveInteger:{type:"integer",minimum:0},positiveIntegerDefault0:{allOf:[{$ref:"#/definitions/positiveInteger"},{default:0}]},simpleTypes:{type:"string",enum:["array","boolean","integer","null","number","object","string"]},stringArray:{type:"array",items:{type:"string"},minItems:1,uniqueItems:!0}},type:"object",properties:{id:{type:"string",format:"uri"},$schema:{type:"string",format:"uri"},title:{type:"string"},description:{type:"string"},default:{},multipleOf:{type:"number",minimum:0,exclusiveMinimum:!0},maximum:{type:"number"},exclusiveMaximum:{type:"boolean",default:!1},minimum:{type:"number"},exclusiveMinimum:{type:"boolean",default:!1},maxLength:{allOf:[{$ref:"#/definitions/positiveInteger"}]},minLength:{allOf:[{$ref:"#/definitions/positiveIntegerDefault0"}]},pattern:{type:"string",format:"regex"},additionalItems:{anyOf:[{type:"boolean"},{$ref:"#"}],default:{}},items:{anyOf:[{$ref:"#"},{$ref:"#/definitions/schemaArray"}],default:{}},maxItems:{allOf:[{$ref:"#/definitions/positiveInteger"}]},minItems:{allOf:[{$ref:"#/definitions/positiveIntegerDefault0"}]},uniqueItems:{type:"boolean",default:!1},maxProperties:{allOf:[{$ref:"#/definitions/positiveInteger"}]},minProperties:{allOf:[{$ref:"#/definitions/positiveIntegerDefault0"}]},required:{allOf:[{$ref:"#/definitions/stringArray"}]},additionalProperties:{anyOf:[{type:"boolean"},{$ref:"#"}],default:{}},definitions:{type:"object",additionalProperties:{$ref:"#"},default:{}},properties:{type:"object",additionalProperties:{$ref:"#"},default:{}},patternProperties:{type:"object",additionalProperties:{$ref:"#"},default:{}},dependencies:{type:"object",additionalProperties:{anyOf:[{$ref:"#"},{$ref:"#/definitions/stringArray"}]}},enum:{type:"array",minItems:1,uniqueItems:!0},type:{anyOf:[{$ref:"#/definitions/simpleTypes"},{type:"array",items:{$ref:"#/definitions/simpleTypes"},minItems:1,uniqueItems:!0}]},format:{anyOf:[{type:"string",enum:["date-time","uri","email","hostname","ipv4","ipv6","regex"]},{type:"string"}]},allOf:{allOf:[{$ref:"#/definitions/schemaArray"}]},anyOf:{allOf:[{$ref:"#/definitions/schemaArray"}]},oneOf:{allOf:[{$ref:"#/definitions/schemaArray"}]},not:{allOf:[{$ref:"#"}]}},dependencies:{exclusiveMaximum:["maximum"],exclusiveMinimum:["minimum"]},default:{}},"http://json-schema.org/draft-07/schema#":{definitions:{schemaArray:{type:"array",minItems:1,items:{$ref:"#"}},nonNegativeInteger:{type:"integer",minimum:0},nonNegativeIntegerDefault0:{allOf:[{$ref:"#/definitions/nonNegativeInteger"},{default:0}]},simpleTypes:{enum:["array","boolean","integer","null","number","object","string"]},stringArray:{type:"array",items:{type:"string"},uniqueItems:!0,default:[]}},type:["object","boolean"],properties:{$id:{type:"string",format:"uri-reference"},$schema:{type:"string",format:"uri"},$ref:{type:"string",format:"uri-reference"},$comment:{type:"string"},title:{type:"string"},description:{type:"string"},default:!0,readOnly:{type:"boolean",default:!1},examples:{type:"array",items:!0},multipleOf:{type:"number",exclusiveMinimum:0},maximum:{type:"number"},exclusiveMaximum:{type:"number"},minimum:{type:"number"},exclusiveMinimum:{type:"number"},maxLength:{$ref:"#/definitions/nonNegativeInteger"},minLength:{$ref:"#/definitions/nonNegativeIntegerDefault0"},pattern:{type:"string",format:"regex"},additionalItems:{$ref:"#"},items:{anyOf:[{$ref:"#"},{$ref:"#/definitions/schemaArray"}],default:!0},maxItems:{$ref:"#/definitions/nonNegativeInteger"},minItems:{$ref:"#/definitions/nonNegativeIntegerDefault0"},uniqueItems:{type:"boolean",default:!1},contains:{$ref:"#"},maxProperties:{$ref:"#/definitions/nonNegativeInteger"},minProperties:{$ref:"#/definitions/nonNegativeIntegerDefault0"},required:{$ref:"#/definitions/stringArray"},additionalProperties:{$ref:"#"},definitions:{type:"object",additionalProperties:{$ref:"#"},default:{}},properties:{type:"object",additionalProperties:{$ref:"#"},default:{}},patternProperties:{type:"object",additionalProperties:{$ref:"#"},propertyNames:{format:"regex"},default:{}},dependencies:{type:"object",additionalProperties:{anyOf:[{$ref:"#"},{$ref:"#/definitions/stringArray"}]}},propertyNames:{$ref:"#"},const:!0,enum:{type:"array",items:!0,minItems:1,uniqueItems:!0},type:{anyOf:[{$ref:"#/definitions/simpleTypes"},{type:"array",items:{$ref:"#/definitions/simpleTypes"},minItems:1,uniqueItems:!0}]},format:{type:"string"},contentMediaType:{type:"string"},contentEncoding:{type:"string"},if:{$ref:"#"},then:{$ref:"#"},else:{$ref:"#"},allOf:{$ref:"#/definitions/schemaArray"},anyOf:{$ref:"#/definitions/schemaArray"},oneOf:{$ref:"#/definitions/schemaArray"},not:{$ref:"#"}},default:!0}}},mr={id:xn("A unique identifier for the schema."),$schema:xn("The schema to verify this document against."),title:xn("A descriptive title of the element."),description:xn("A long description of the element. Used in hover menus and suggestions."),default:xn("A default value. Used by suggestions."),multipleOf:xn("A number that should cleanly divide the current value (i.e. have no remainder)."),maximum:xn("The maximum numerical value, inclusive by default."),exclusiveMaximum:xn("Makes the maximum property exclusive."),minimum:xn("The minimum numerical value, inclusive by default."),exclusiveMinimum:xn("Makes the minimum property exclusive."),maxLength:xn("The maximum length of a string."),minLength:xn("The minimum length of a string."),pattern:xn("A regular expression to match the string against. It is not implicitly anchored."),additionalItems:xn("For arrays, only when items is set as an array. If it is a schema, then this schema validates items after the ones specified by the items array. If it is false, then additional items will cause validation to fail."),items:xn("For arrays. Can either be a schema to validate every element against or an array of schemas to validate each item against in order (the first schema will validate the first element, the second schema will validate the second element, and so on."),maxItems:xn("The maximum number of items that can be inside an array. Inclusive."),minItems:xn("The minimum number of items that can be inside an array. Inclusive."),uniqueItems:xn("If all of the items in the array must be unique. Defaults to false."),maxProperties:xn("The maximum number of properties an object can have. Inclusive."),minProperties:xn("The minimum number of properties an object can have. Inclusive."),required:xn("An array of strings that lists the names of all properties required on this object."),additionalProperties:xn("Either a schema or a boolean. If a schema, then used to validate all properties not matched by 'properties' or 'patternProperties'. If false, then any properties not matched by either will cause this schema to fail."),definitions:xn("Not used for validation. Place subschemas here that you wish to reference inline with $ref."),properties:xn("A map of property names to schemas for each property."),patternProperties:xn("A map of regular expressions on property names to schemas for matching properties."),dependencies:xn("A map of property names to either an array of property names or a schema. An array of property names means the property named in the key depends on the properties in the array being present in the object in order to be valid. If the value is a schema, then the schema is only applied to the object if the property in the key exists on the object."),enum:xn("The set of literal values that are valid."),type:xn("Either a string of one of the basic schema types (number, integer, null, array, object, boolean, string) or an array of strings specifying a subset of those types."),format:xn("Describes the format expected for the value."),allOf:xn("An array of schemas, all of which must match."),anyOf:xn("An array of schemas, where at least one must match."),oneOf:xn("An array of schemas, exactly one of which must match."),not:xn("A schema which must not match."),$id:xn("A unique identifier for the schema."),$ref:xn("Reference a definition hosted on any location."),$comment:xn("Comments from schema authors to readers or maintainers of the schema."),readOnly:xn("Indicates that the value of the instance is managed exclusively by the owning authority."),examples:xn("Sample JSON values associated with a particular schema, for the purpose of illustrating usage."),contains:xn('An array instance is valid against "contains" if at least one of its elements is valid against the given schema.'),propertyNames:xn("If the instance is an object, this keyword validates if every property name in the instance validates against the provided schema."),const:xn("An instance validates successfully against this keyword if its value is equal to the value of the keyword."),contentMediaType:xn("Describes the media type of a string property."),contentEncoding:xn("Describes the content encoding of a string property."),if:xn('The validation outcome of the "if" subschema controls which of the "then" or "else" keywords are evaluated.'),then:xn('The "if" subschema is used for validation when the "if" subschema succeeds.'),else:xn('The "else" subschema is used for validation when the "if" subschema fails.')};for(const n in fr.schemas){const e=fr.schemas[n];for(const t in e.properties){let n=e.properties[t];"boolean"===typeof n&&(n=e.properties[t]={});const r=mr[t];r&&(n.description=r)}}(()=>{var e={470:e=>{function t(e){if("string"!=typeof e)throw new TypeError("Path must be a string. Received "+JSON.stringify(e))}function n(e,t){for(var n,r="",i=0,s=-1,o=0,a=0;a<=e.length;++a){if(a2){var l=r.lastIndexOf("/");if(l!==r.length-1){-1===l?(r="",i=0):i=(r=r.slice(0,l)).length-1-r.lastIndexOf("/"),s=a,o=0;continue}}else if(2===r.length||1===r.length){r="",i=0,s=a,o=0;continue}t&&(r.length>0?r+="/..":r="..",i=2)}else r.length>0?r+="/"+e.slice(s+1,a):r=e.slice(s+1,a),i=a-s-1;s=a,o=0}else 46===n&&-1!==o?++o:o=-1}return r}var r={resolve:function(){for(var e,r="",i=!1,s=arguments.length-1;s>=-1&&!i;s--){var o;s>=0?o=arguments[s]:(void 0===e&&(e=process.cwd()),o=e),t(o),0!==o.length&&(r=o+"/"+r,i=47===o.charCodeAt(0))}return r=n(r,!i),i?r.length>0?"/"+r:"/":r.length>0?r:"."},normalize:function(e){if(t(e),0===e.length)return".";var r=47===e.charCodeAt(0),i=47===e.charCodeAt(e.length-1);return 0!==(e=n(e,!r)).length||r||(e="."),e.length>0&&i&&(e+="/"),r?"/"+e:e},isAbsolute:function(e){return t(e),e.length>0&&47===e.charCodeAt(0)},join:function(){if(0===arguments.length)return".";for(var e,n=0;n0&&(void 0===e?e=i:e+="/"+i)}return void 0===e?".":r.normalize(e)},relative:function(e,n){if(t(e),t(n),e===n)return"";if((e=r.resolve(e))===(n=r.resolve(n)))return"";for(var i=1;ic){if(47===n.charCodeAt(a+u))return n.slice(a+u+1);if(0===u)return n.slice(a+u)}else o>c&&(47===e.charCodeAt(i+u)?h=u:0===u&&(h=0));break}var d=e.charCodeAt(i+u);if(d!==n.charCodeAt(a+u))break;47===d&&(h=u)}var g="";for(u=i+h+1;u<=s;++u)u!==s&&47!==e.charCodeAt(u)||(0===g.length?g+="..":g+="/..");return g.length>0?g+n.slice(a+h):(a+=h,47===n.charCodeAt(a)&&++a,n.slice(a))},_makeLong:function(e){return e},dirname:function(e){if(t(e),0===e.length)return".";for(var n=e.charCodeAt(0),r=47===n,i=-1,s=!0,o=e.length-1;o>=1;--o)if(47===(n=e.charCodeAt(o))){if(!s){i=o;break}}else s=!1;return-1===i?r?"/":".":r&&1===i?"//":e.slice(0,i)},basename:function(e,n){if(void 0!==n&&"string"!=typeof n)throw new TypeError('"ext" argument must be a string');t(e);var r,i=0,s=-1,o=!0;if(void 0!==n&&n.length>0&&n.length<=e.length){if(n.length===e.length&&n===e)return"";var a=n.length-1,l=-1;for(r=e.length-1;r>=0;--r){var c=e.charCodeAt(r);if(47===c){if(!o){i=r+1;break}}else-1===l&&(o=!1,l=r+1),a>=0&&(c===n.charCodeAt(a)?-1==--a&&(s=r):(a=-1,s=l))}return i===s?s=l:-1===s&&(s=e.length),e.slice(i,s)}for(r=e.length-1;r>=0;--r)if(47===e.charCodeAt(r)){if(!o){i=r+1;break}}else-1===s&&(o=!1,s=r+1);return-1===s?"":e.slice(i,s)},extname:function(e){t(e);for(var n=-1,r=0,i=-1,s=!0,o=0,a=e.length-1;a>=0;--a){var l=e.charCodeAt(a);if(47!==l)-1===i&&(s=!1,i=a+1),46===l?-1===n?n=a:1!==o&&(o=1):-1!==n&&(o=-1);else if(!s){r=a+1;break}}return-1===n||-1===i||0===o||1===o&&n===i-1&&n===r+1?"":e.slice(n,i)},format:function(e){if(null===e||"object"!=typeof e)throw new TypeError('The "pathObject" argument must be of type Object. Received type '+typeof e);return function(e,t){var n=t.dir||t.root,r=t.base||(t.name||"")+(t.ext||"");return n?n===t.root?n+r:n+"/"+r:r}(0,e)},parse:function(e){t(e);var n={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return n;var r,i=e.charCodeAt(0),s=47===i;s?(n.root="/",r=1):r=0;for(var o=-1,a=0,l=-1,c=!0,h=e.length-1,u=0;h>=r;--h)if(47!==(i=e.charCodeAt(h)))-1===l&&(c=!1,l=h+1),46===i?-1===o?o=h:1!==u&&(u=1):-1!==o&&(u=-1);else if(!c){a=h+1;break}return-1===o||-1===l||0===u||1===u&&o===l-1&&o===a+1?-1!==l&&(n.base=n.name=0===a&&s?e.slice(1,l):e.slice(a,l)):(0===a&&s?(n.name=e.slice(1,o),n.base=e.slice(1,l)):(n.name=e.slice(a,o),n.base=e.slice(a,l)),n.ext=e.slice(o,l)),a>0?n.dir=e.slice(0,a-1):s&&(n.dir="/"),n},sep:"/",delimiter:":",win32:null,posix:null};r.posix=r,e.exports=r}},t={};function n(r){var i=t[r];if(void 0!==i)return i.exports;var s=t[r]={exports:{}};return e[r](s,s.exports,n),s.exports}n.d=(e,t)=>{for(var r in t)n.o(t,r)&&!n.o(e,r)&&Object.defineProperty(e,r,{enumerable:!0,get:t[r]})},n.o=(e,t)=>Object.prototype.hasOwnProperty.call(e,t),n.r=e=>{"undefined"!=typeof Symbol&&Symbol.toStringTag&&Object.defineProperty(e,Symbol.toStringTag,{value:"Module"}),Object.defineProperty(e,"__esModule",{value:!0})};var r={};(()=>{let e;if(n.r(r),n.d(r,{URI:()=>h,Utils:()=>w}),"object"==typeof process)e="win32"===process.platform;else if("object"==typeof navigator){let t=navigator.userAgent;e=t.indexOf("Windows")>=0}const t=/^\w[\w\d+.-]*$/,i=/^\//,s=/^\/\//;function o(e,n){if(!e.scheme&&n)throw new Error(`[UriError]: Scheme is missing: {scheme: "", authority: "${e.authority}", path: "${e.path}", query: "${e.query}", fragment: "${e.fragment}"}`);if(e.scheme&&!t.test(e.scheme))throw new Error("[UriError]: Scheme contains illegal characters.");if(e.path)if(e.authority){if(!i.test(e.path))throw new Error('[UriError]: If a URI contains an authority component, then the path component must either be empty or begin with a slash ("/") character')}else if(s.test(e.path))throw new Error('[UriError]: If a URI does not contain an authority component, then the path cannot begin with two slash characters ("//")')}const a="",l="/",c=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/;class h{static isUri(e){return e instanceof h||!!e&&"string"==typeof e.authority&&"string"==typeof e.fragment&&"string"==typeof e.path&&"string"==typeof e.query&&"string"==typeof e.scheme&&"string"==typeof e.fsPath&&"function"==typeof e.with&&"function"==typeof e.toString}scheme;authority;path;query;fragment;constructor(e,t,n,r,i,s=!1){"object"==typeof e?(this.scheme=e.scheme||a,this.authority=e.authority||a,this.path=e.path||a,this.query=e.query||a,this.fragment=e.fragment||a):(this.scheme=function(e,t){return e||t?e:"file"}(e,s),this.authority=t||a,this.path=function(e,t){switch(e){case"https":case"http":case"file":t?t[0]!==l&&(t=l+t):t=l}return t}(this.scheme,n||a),this.query=r||a,this.fragment=i||a,o(this,s))}get fsPath(){return p(this,!1)}with(e){if(!e)return this;let{scheme:t,authority:n,path:r,query:i,fragment:s}=e;return void 0===t?t=this.scheme:null===t&&(t=a),void 0===n?n=this.authority:null===n&&(n=a),void 0===r?r=this.path:null===r&&(r=a),void 0===i?i=this.query:null===i&&(i=a),void 0===s?s=this.fragment:null===s&&(s=a),t===this.scheme&&n===this.authority&&r===this.path&&i===this.query&&s===this.fragment?this:new d(t,n,r,i,s)}static parse(e,t=!1){const n=c.exec(e);return n?new d(n[2]||a,v(n[4]||a),v(n[5]||a),v(n[7]||a),v(n[9]||a),t):new d(a,a,a,a,a)}static file(t){let n=a;if(e&&(t=t.replace(/\\/g,l)),t[0]===l&&t[1]===l){const e=t.indexOf(l,2);-1===e?(n=t.substring(2),t=l):(n=t.substring(2,e),t=t.substring(e)||l)}return new d("file",n,t,a,a)}static from(e){const t=new d(e.scheme,e.authority,e.path,e.query,e.fragment);return o(t,!0),t}toString(e=!1){return b(this,e)}toJSON(){return this}static revive(e){if(e){if(e instanceof h)return e;{const t=new d(e);return t._formatted=e.external,t._fsPath=e._sep===u?e.fsPath:null,t}}return e}}const u=e?1:void 0;class d extends h{_formatted=null;_fsPath=null;get fsPath(){return this._fsPath||(this._fsPath=p(this,!1)),this._fsPath}toString(e=!1){return e?b(this,!0):(this._formatted||(this._formatted=b(this,!1)),this._formatted)}toJSON(){const e={$mid:1};return this._fsPath&&(e.fsPath=this._fsPath,e._sep=u),this._formatted&&(e.external=this._formatted),this.path&&(e.path=this.path),this.scheme&&(e.scheme=this.scheme),this.authority&&(e.authority=this.authority),this.query&&(e.query=this.query),this.fragment&&(e.fragment=this.fragment),e}}const g={58:"%3A",47:"%2F",63:"%3F",35:"%23",91:"%5B",93:"%5D",64:"%40",33:"%21",36:"%24",38:"%26",39:"%27",40:"%28",41:"%29",42:"%2A",43:"%2B",44:"%2C",59:"%3B",61:"%3D",32:"%20"};function f(e,t,n){let r,i=-1;for(let s=0;s=97&&o<=122||o>=65&&o<=90||o>=48&&o<=57||45===o||46===o||95===o||126===o||t&&47===o||n&&91===o||n&&93===o||n&&58===o)-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),void 0!==r&&(r+=e.charAt(s));else{void 0===r&&(r=e.substr(0,s));const t=g[o];void 0!==t?(-1!==i&&(r+=encodeURIComponent(e.substring(i,s)),i=-1),r+=t):-1===i&&(i=s)}}return-1!==i&&(r+=encodeURIComponent(e.substring(i))),void 0!==r?r:e}function m(e){let t;for(let n=0;n1&&"file"===t.scheme?`//${t.authority}${t.path}`:47===t.path.charCodeAt(0)&&(t.path.charCodeAt(1)>=65&&t.path.charCodeAt(1)<=90||t.path.charCodeAt(1)>=97&&t.path.charCodeAt(1)<=122)&&58===t.path.charCodeAt(2)?n?t.path.substr(1):t.path[1].toLowerCase()+t.path.substr(2):t.path,e&&(r=r.replace(/\//g,"\\")),r}function b(e,t){const n=t?m:f;let r="",{scheme:i,authority:s,path:o,query:a,fragment:c}=e;if(i&&(r+=i,r+=":"),(s||"file"===i)&&(r+=l,r+=l),s){let e=s.indexOf("@");if(-1!==e){const t=s.substr(0,e);s=s.substr(e+1),e=t.lastIndexOf(":"),-1===e?r+=n(t,!1,!1):(r+=n(t.substr(0,e),!1,!1),r+=":",r+=n(t.substr(e+1),!1,!0)),r+="@"}s=s.toLowerCase(),e=s.lastIndexOf(":"),-1===e?r+=n(s,!1,!0):(r+=n(s.substr(0,e),!1,!0),r+=s.substr(e))}if(o){if(o.length>=3&&47===o.charCodeAt(0)&&58===o.charCodeAt(2)){const e=o.charCodeAt(1);e>=65&&e<=90&&(o=`/${String.fromCharCode(e+32)}:${o.substr(3)}`)}else if(o.length>=2&&58===o.charCodeAt(1)){const e=o.charCodeAt(0);e>=65&&e<=90&&(o=`${String.fromCharCode(e+32)}:${o.substr(2)}`)}r+=n(o,!0,!1)}return a&&(r+="?",r+=n(a,!1,!1)),c&&(r+="#",r+=t?c:f(c,!1,!1)),r}function _(e){try{return decodeURIComponent(e)}catch{return e.length>3?e.substr(0,3)+_(e.substr(3)):e}}const k=/(%[0-9A-Za-z][0-9A-Za-z])+/g;function v(e){return e.match(k)?e.replace(k,(e=>_(e))):e}var C=n(470);const y=C.posix||C,L="/";var w,S;(S=w||(w={})).joinPath=function(e,...t){return e.with({path:y.join(e.path,...t)})},S.resolvePath=function(e,...t){let n=e.path,r=!1;n[0]!==L&&(n=L+n,r=!0);let i=y.resolve(n,...t);return r&&i[0]===L&&!e.authority&&(i=i.substring(1)),e.with({path:i})},S.dirname=function(e){if(0===e.path.length||e.path===L)return e;let t=y.dirname(e.path);return 1===t.length&&46===t.charCodeAt(0)&&(t=""),e.with({path:t})},S.basename=function(e){return y.basename(e.path)},S.extname=function(e){return y.extname(e.path)}})(),gr=r})();var{URI:pr,Utils:br}=gr;function _r(e,t){if("string"!==typeof e)throw new TypeError("Expected a string");const n=String(e);let r="";const i=!!t&&!!t.extended,s=!!t&&!!t.globstar;let o=!1;const a=t&&"string"===typeof t.flags?t.flags:"";let l;for(let c=0,h=n.length;c1&&("/"===e||void 0===e||"{"===e||","===e)&&("/"===a||void 0===a||","===a||"}"===a)?("/"===a?c++:"/"===e&&r.endsWith("\\/")&&(r=r.substr(0,r.length-2)),r+="((?:[^/]*(?:/|$))*)"):r+="([^/]*)"}else r+=".*";break;default:r+=l}return a&&~a.indexOf("g")||(r="^"+r+"$"),new RegExp(r,a)}var kr,vr,Cr=class{constructor(e,t,n){this.folderUri=t,this.uris=n,this.globWrappers=[];try{for(let t of e){const e="!"!==t[0];e||(t=t.substring(1)),t.length>0&&("/"===t[0]&&(t=t.substring(1)),this.globWrappers.push({regexp:_r("**/"+t,{extended:!0,globstar:!0}),include:e}))}t&&((t=Nr(t)).endsWith("/")||(t+="/"),this.folderUri=t)}catch(r){this.globWrappers.length=0,this.uris=[]}}matchesPattern(e){if(this.folderUri&&!e.startsWith(this.folderUri))return!1;let t=!1;for(const{regexp:n,include:r}of this.globWrappers)n.test(e)&&(t=r);return t}getURIs(){return this.uris}},yr=class{constructor(e,t,n){this.service=e,this.uri=t,this.dependencies=new Set,this.anchors=void 0,n&&(this.unresolvedSchema=this.service.promise.resolve(new Lr(n)))}getUnresolvedSchema(){return this.unresolvedSchema||(this.unresolvedSchema=this.service.loadSchema(this.uri)),this.unresolvedSchema}getResolvedSchema(){return this.resolvedSchema||(this.resolvedSchema=this.getUnresolvedSchema().then((e=>this.service.resolveSchemaContent(e,this)))),this.resolvedSchema}clearSchema(){const e=!!this.unresolvedSchema;return this.resolvedSchema=void 0,this.unresolvedSchema=void 0,this.dependencies.clear(),this.anchors=void 0,e}},Lr=class{constructor(e,t=[]){this.schema=e,this.errors=t}},wr=class{constructor(e,t=[],n=[],r){this.schema=e,this.errors=t,this.warnings=n,this.schemaDraft=r}getSection(e){const t=this.getSectionRecursive(e,this.schema);if(t)return zn(t)}getSectionRecursive(e,t){if(!t||"boolean"===typeof t||0===e.length)return t;const n=e.shift();if(t.properties&&(t.properties[n],1))return this.getSectionRecursive(e,t.properties[n]);if(t.patternProperties)for(const r of Object.keys(t.patternProperties)){const i=hn(r);if(i?.test(n))return this.getSectionRecursive(e,t.patternProperties[r])}else{if("object"===typeof t.additionalProperties)return this.getSectionRecursive(e,t.additionalProperties);if(n.match("[0-9]+"))if(Array.isArray(t.items)){const r=parseInt(n,10);if(!isNaN(r)&&t.items[r])return this.getSectionRecursive(e,t.items[r])}else if(t.items)return this.getSectionRecursive(e,t.items)}}},Sr=class{constructor(e,t,n){this.contextService=t,this.requestService=e,this.promiseConstructor=n||Promise,this.callOnDispose=[],this.contributionSchemas={},this.contributionAssociations=[],this.schemasById={},this.filePatternAssociations=[],this.registeredSchemasIds={}}getRegisteredSchemaIds(e){return Object.keys(this.registeredSchemasIds).filter((t=>{const n=pr.parse(t).scheme;return"schemaservice"!==n&&(!e||e(n))}))}get promise(){return this.promiseConstructor}dispose(){for(;this.callOnDispose.length>0;)this.callOnDispose.pop()()}onResourceChange(e){this.cachedSchemaForResource=void 0;let t=!1;const n=[e=Er(e)],r=Object.keys(this.schemasById).map((e=>this.schemasById[e]));for(;n.length;){const e=n.pop();for(let i=0;i{if(!t){const t=xn("Unable to load schema from '{0}': No content.",Tr(e));return new Lr({},[t])}const n=[];65279===t.charCodeAt(0)&&(n.push(xn("Problem reading content from '{0}': UTF-8 with BOM detected, only UTF 8 is allowed.",Tr(e))),t=t.trimStart());let r={};const i=[];return r=Yt(t,i),i.length&&n.push(xn("Unable to parse content from '{0}': Parse error at offset {1}.",Tr(e),i[0].offset)),new Lr(r,n)}),(t=>{let n=t.toString();const r=t.toString().split("Error: ");return r.length>1&&(n=r[1]),cn(n,".")&&(n=n.substr(0,n.length-1)),new Lr({},[xn("Unable to load schema from '{0}': {1}.",Tr(e),n)])}))}resolveSchemaContent(e,t){const n=e.errors.slice(0),r=e.schema;let i=r.$schema?Er(r.$schema):void 0;if("http://json-schema.org/draft-03/schema"===i)return this.promise.resolve(new wr({},[xn("Draft-03 schemas are not supported.")],[],i));let s=new Set;const o=this.contextService,a=(e,t,r,i)=>{let s;var o,a,l;void 0===i||0===i.length?s=t:"/"===i.charAt(0)?s=((e,t)=>{t=decodeURIComponent(t);let n=e;return"/"===t[0]&&(t=t.substring(1)),t.split("/").some((e=>(e=e.replace(/~1/g,"/").replace(/~0/g,"~"),n=n[e],!n))),n})(t,i):(o=t,l=i,(a=r).anchors||(a.anchors=h(o)),s=a.anchors.get(l)),s?((e,t)=>{for(const n in t)t.hasOwnProperty(n)&&"id"!==n&&"$id"!==n&&(e[n]=t[n])})(e,s):n.push(xn("$ref '{0}' in '{1}' can not be resolved.",i||"",r.uri))},l=(e,t,r,i)=>{o&&!/^[A-Za-z][A-Za-z0-9+\-.+]*:\/\/.*/.test(t)&&(t=o.resolveRelativePath(t,i.uri)),t=Er(t);const s=this.getOrAddSchemaHandle(t);return s.getUnresolvedSchema().then((o=>{if(i.dependencies.add(t),o.errors.length){const e=r?t+"#"+r:t;n.push(xn("Problems loading reference '{0}': {1}",e,o.errors[0]))}return a(e,o.schema,s,r),c(e,o.schema,s)}))},c=(e,t,n)=>{const r=[];return this.traverseNodes(e,(e=>{const i=new Set;for(;e.$ref;){const s=e.$ref,o=s.split("#",2);if(delete e.$ref,o[0].length>0)return void r.push(l(e,o[0],o[1],n));if(!i.has(s)){const r=o[1];a(e,t,n,r),i.add(s)}}e.$recursiveRef&&s.add("$recursiveRef"),e.$dynamicRef&&s.add("$dynamicRef")})),this.promise.all(r)},h=e=>{const t=new Map;return this.traverseNodes(e,(e=>{const r=e.$id||e.id,i=an(r)&&"#"===r.charAt(0)?r.substring(1):e.$anchor;i&&(t.has(i)?n.push(xn("Duplicate anchor declaration: '{0}'",i)):t.set(i,e)),e.$recursiveAnchor&&s.add("$recursiveAnchor"),e.$dynamicAnchor&&s.add("$dynamicAnchor")})),t};return c(r,r,t).then((e=>{let t=[];return s.size&&t.push(xn("The schema uses meta-schema features ({0}) that are not yet supported by the validator.",Array.from(s.keys()).join(", "))),new wr(r,n,t,i)}))}traverseNodes(e,t){if(!e||"object"!==typeof e)return Promise.resolve(null);const n=new Set,r=(...e)=>{for(const t of e)ln(t)&&a.push(t)},i=(...e)=>{for(const t of e)if(ln(t))for(const e in t){const n=t[e];ln(n)&&a.push(n)}},s=(...e)=>{for(const t of e)if(Array.isArray(t))for(const e of t)ln(e)&&a.push(e)},o=e=>{if(Array.isArray(e))for(const t of e)ln(t)&&a.push(t);else ln(e)&&a.push(e)},a=[e];let l=a.pop();for(;l;)n.has(l)||(n.add(l),t(l),r(l.additionalItems,l.additionalProperties,l.not,l.contains,l.propertyNames,l.if,l.then,l.else,l.unevaluatedItems,l.unevaluatedProperties),i(l.definitions,l.$defs,l.properties,l.patternProperties,l.dependencies,l.dependentSchemas),s(l.anyOf,l.allOf,l.oneOf,l.prefixItems),o(l.items)),l=a.pop()}getSchemaFromProperty(e,t){if("object"===t.root?.type)for(const n of t.root.properties)if("$schema"===n.keyNode.value&&"string"===n.valueNode?.type){let t=n.valueNode.value;return this.contextService&&!/^\w[\w\d+.-]*:/.test(t)&&(t=this.contextService.resolveRelativePath(t,e)),t}}getAssociatedSchemas(e){const t=Object.create(null),n=[],r=Nr(e);for(const i of this.filePatternAssociations)if(i.matchesPattern(r))for(const e of i.getURIs())t[e]||(n.push(e),t[e]=!0);return n}getSchemaURIsForResource(e,t){let n=t&&this.getSchemaFromProperty(e,t);return n?[n]:this.getAssociatedSchemas(e)}getSchemaForResource(e,t){if(t){let n=this.getSchemaFromProperty(e,t);if(n){const e=Er(n);return this.getOrAddSchemaHandle(e).getResolvedSchema()}}if(this.cachedSchemaForResource&&this.cachedSchemaForResource.resource===e)return this.cachedSchemaForResource.resolvedSchema;const n=this.getAssociatedSchemas(e),r=n.length>0?this.createCombinedSchema(e,n).getResolvedSchema():this.promise.resolve(void 0);return this.cachedSchemaForResource={resource:e,resolvedSchema:r},r}createCombinedSchema(e,t){if(1===t.length)return this.getOrAddSchemaHandle(t[0]);{const n="schemaservice://combinedSchema/"+encodeURIComponent(e),r={allOf:t.map((e=>({$ref:e})))};return this.addSchemaHandle(n,r)}}getMatchingSchemas(e,t,n){if(n){const e=n.id||"schemaservice://untitled/matchingSchemas/"+xr++;return this.addSchemaHandle(e,n).getResolvedSchema().then((e=>t.getMatchingSchemas(e.schema).filter((e=>!e.inverted))))}return this.getSchemaForResource(e.uri,t).then((e=>e?t.getMatchingSchemas(e.schema).filter((e=>!e.inverted)):[]))}},xr=0;function Er(e){try{return pr.parse(e).toString(!0)}catch(t){return e}}function Nr(e){try{return pr.parse(e).with({fragment:null,query:null}).toString(!0)}catch(t){return e}}function Tr(e){try{const t=pr.parse(e);if("file"===t.scheme)return t.fsPath}catch(t){}return e}function Ar(e,t){const n=[],r=[],i=[];let s=-1;const o=w(e.getText(),!1);let a=o.scan();function l(e){n.push(e),r.push(i.length)}for(;17!==a;){switch(a){case 1:case 3:{const t=e.positionAt(o.getTokenOffset()).line,n={startLine:t,endLine:t,kind:1===a?"object":"array"};i.push(n);break}case 2:case 4:{const t=2===a?"object":"array";if(i.length>0&&i[i.length-1].kind===t){const t=i.pop(),n=e.positionAt(o.getTokenOffset()).line;t&&n>t.startLine+1&&s!==t.startLine&&(t.endLine=n-1,l(t),s=t.startLine)}break}case 13:{const t=e.positionAt(o.getTokenOffset()).line,n=e.positionAt(o.getTokenOffset()+o.getTokenLength()).line;1===o.getTokenError()&&t+1=0&&i[e].kind!==K.Region;)e--;if(e>=0){const t=i[e];i.length=e,n>t.startLine&&s!==t.startLine&&(t.endLine=n,l(t),s=t.startLine)}}}break}}a=o.scan()}const c=t&&t.rangeLimit;if("number"!==typeof c||n.length<=c)return n;t&&t.onRangeLimitExceeded&&t.onRangeLimitExceeded(e.uri);const h=[];for(let f of r)f<30&&(h[f]=(h[f]||0)+1);let u=0,d=0;for(let f=0;fc){d=f;break}u+=e}}const g=[];for(let f=0;f=e&&i<=t&&a.push(r(e,t)),a.push(r(o.offset,o.offset+o.length));break;case"number":case"boolean":case"null":case"property":a.push(r(o.offset,o.offset+o.length))}if("property"===o.type||o.parent&&"array"===o.parent.type){const e=s(o.offset+o.length,5);-1!==e&&a.push(r(o.offset,e))}o=o.parent}let l;for(let e=a.length-1;e>=0;e--)l=yt.create(a[e],l);return l||(l=yt.create(D.create(t,t))),l}))}function Or(e,t,n){let r;if(n){const t=e.offsetAt(n.start);r={offset:t,length:e.offsetAt(n.end)-t}}const i={tabSize:t?t.tabSize:4,insertSpaces:!0===t?.insertSpaces,insertFinalNewline:!0===t?.insertFinalNewline,eol:"\n",keepLines:!0===t?.keepLines};return function(e,t,n){return b(e,t,n)}(e.getText(),r,i).map((t=>le.replace(D.create(e.positionAt(t.offset),e.positionAt(t.offset+t.length)),t.content)))}(vr=kr||(kr={}))[vr.Object=0]="Object",vr[vr.Array=1]="Array";var Mr=class{constructor(e,t){this.propertyName=e??"",this.beginningLineNumber=t,this.childrenProperties=[],this.lastProperty=!1,this.noKeyName=!1}addChildProperty(e){if(e.parent=this,this.childrenProperties.length>0){let t=0;t=e.noKeyName?this.childrenProperties.length:function(e,t,n){const r=t.propertyName.toLowerCase(),i=e[0].propertyName.toLowerCase(),s=e[e.length-1].propertyName.toLowerCase();if(rs)return e.length;let o=0,a=e.length-1;for(;o<=a;){let r=a+o>>1,i=n(t,e[r]);if(i>0)o=r+1;else{if(!(i<0))return r;a=r-1}}return-o-1}(this.childrenProperties,e,Rr),t<0&&(t=-1*t-1),this.childrenProperties.splice(t,0,e)}else this.childrenProperties.push(e);return e}};function Rr(e,t){const n=e.propertyName.toLowerCase(),r=t.propertyName.toLowerCase();return nr?1:0}function Dr(e,t){const n={...t,keepLines:!1},r=fn.applyEdits(e,Or(e,n,void 0)),i=fn.create("test://test.json","json",0,r),s=function(e,t){if(0===t.childrenProperties.length)return e;const n=fn.create("test://test.json","json",0,e.getText()),r=[];Br(r,t,t.beginningLineNumber);for(;r.length>0;){const t=r.shift(),i=t.propertyTreeArray;let s=t.beginningLineNumber;for(let o=0;o{if("property"===r.type&&"$ref"===r.keyNode.value&&"string"===r.valueNode?.type){const i=r.valueNode.value,s=function(e,t){const n=function(e){if("#"===e)return[];if("#"!==e[0]||"/"!==e[1])return null;return e.substring(2).split(/\//).map(Wr)}(t);if(!n)return null;return qr(n,e.root)}(t,i);if(s){const t=e.positionAt(s.offset);n.push({target:`${e.uri}#${t.line+1},${t.character+1}`,range:jr(e,r.valueNode)})}}return!0})),Promise.resolve(n)}function jr(e,t){return D.create(e.positionAt(t.offset+1),e.positionAt(t.offset+t.length-1))}function qr(e,t){if(!t)return null;if(0===e.length)return t;const n=e.shift();if(t&&"object"===t.type){const r=t.properties.find((e=>e.keyNode.value===n));return r?qr(e,r.valueNode):null}if(t&&"array"===t.type&&n.match(/^(0|[1-9][0-9]*)$/)){const r=Number.parseInt(n),i=t.items[r];return i?qr(e,i):null}return null}function Wr(e){return e.replace(/~1/g,"/").replace(/~0/g,"~")}function Ur(e){const t=e.promiseConstructor||Promise,n=new Sr(e.schemaRequestService,e.workspaceContext,t);n.setSchemaContributions(fr);const r=new er(n,e.contributions,t,e.clientCapabilities),i=new tr(n,e.contributions,t),s=new hr(n),o=new rr(n,t);return{configure:e=>{n.clearExternalSchemas(),e.schemas?.forEach(n.registerExternalSchema.bind(n)),o.configure(e)},resetSchema:e=>n.onResourceChange(e),doValidation:o.doValidation.bind(o),getLanguageStatus:o.getLanguageStatus.bind(o),parseJSONDocument:e=>Yn(e,{collectComments:!0}),newJSONDocument:(e,t)=>function(e,t=[]){return new Qn(e,t,[])}(e,t),getMatchingSchemas:n.getMatchingSchemas.bind(n),doResolve:r.doResolve.bind(r),doComplete:r.doComplete.bind(r),findDocumentSymbols:s.findDocumentSymbols.bind(s),findDocumentSymbols2:s.findDocumentSymbols2.bind(s),findDocumentColors:s.findDocumentColors.bind(s),getColorPresentations:s.getColorPresentations.bind(s),doHover:i.doHover.bind(i),getFoldingRanges:Ar,getSelectionRanges:Ir,findDefinition:()=>Promise.resolve([]),findLinks:zr,format:(e,t,n)=>Or(e,n,t),sort:(e,t)=>Dr(e,t)}}"undefined"!==typeof fetch&&(Pr=function(e){return fetch(e).then((e=>e.text()))});var $r=class{constructor(e,t){this._ctx=e,this._languageSettings=t.languageSettings,this._languageId=t.languageId,this._languageService=Ur({workspaceContext:{resolveRelativePath:(e,t)=>function(e,t){if(function(e){return e.charCodeAt(0)===Hr}(t)){const n=pr.parse(e),r=t.split("/");return n.with({path:Gr(r)}).toString()}return function(e,...t){const n=pr.parse(e),r=n.path.split("/");for(let i of t)r.push(...i.split("/"));return n.with({path:Gr(r)}).toString()}(e,t)}(t.substr(0,t.lastIndexOf("/")+1),e)},schemaRequestService:t.enableSchemaRequest?Pr:void 0,clientCapabilities:vn.LATEST}),this._languageService.configure(this._languageSettings)}async doValidation(e){let t=this._getTextDocument(e);if(t){let e=this._languageService.parseJSONDocument(t);return this._languageService.doValidation(t,e,this._languageSettings)}return Promise.resolve([])}async doComplete(e,t){let n=this._getTextDocument(e);if(!n)return null;let r=this._languageService.parseJSONDocument(n);return this._languageService.doComplete(n,t,r)}async doResolve(e){return this._languageService.doResolve(e)}async doHover(e,t){let n=this._getTextDocument(e);if(!n)return null;let r=this._languageService.parseJSONDocument(n);return this._languageService.doHover(n,t,r)}async format(e,t,n){let r=this._getTextDocument(e);if(!r)return[];let i=this._languageService.format(r,t,n);return Promise.resolve(i)}async resetSchema(e){return Promise.resolve(this._languageService.resetSchema(e))}async findDocumentSymbols(e){let t=this._getTextDocument(e);if(!t)return[];let n=this._languageService.parseJSONDocument(t),r=this._languageService.findDocumentSymbols2(t,n);return Promise.resolve(r)}async findDocumentColors(e){let t=this._getTextDocument(e);if(!t)return[];let n=this._languageService.parseJSONDocument(t),r=this._languageService.findDocumentColors(t,n);return Promise.resolve(r)}async getColorPresentations(e,t,n){let r=this._getTextDocument(e);if(!r)return[];let i=this._languageService.parseJSONDocument(r),s=this._languageService.getColorPresentations(r,i,t,n);return Promise.resolve(s)}async getFoldingRanges(e,t){let n=this._getTextDocument(e);if(!n)return[];let r=this._languageService.getFoldingRanges(n,t);return Promise.resolve(r)}async getSelectionRanges(e,t){let n=this._getTextDocument(e);if(!n)return[];let r=this._languageService.parseJSONDocument(n),i=this._languageService.getSelectionRanges(n,t,r);return Promise.resolve(i)}async parseJSONDocument(e){let t=this._getTextDocument(e);if(!t)return null;let n=this._languageService.parseJSONDocument(t);return Promise.resolve(n)}async getMatchingSchemas(e){let t=this._getTextDocument(e);if(!t)return[];let n=this._languageService.parseJSONDocument(t);return Promise.resolve(this._languageService.getMatchingSchemas(t,n))}_getTextDocument(e){let t=this._ctx.getMirrorModels();for(let n of t)if(n.uri.toString()===e)return fn.create(e,this._languageId,n.version,n.getValue());return null}},Hr="/".charCodeAt(0),Kr=".".charCodeAt(0);function Gr(e){const t=[];for(const r of e)0===r.length||1===r.length&&r.charCodeAt(0)===Kr||(2===r.length&&r.charCodeAt(0)===Kr&&r.charCodeAt(1)===Kr?t.pop():t.push(r));e.length>1&&0===e[e.length-1].length&&t.push("");let n=t.join("/");return 0===e[0].length&&(n="/"+n),n}self.onmessage=()=>{s(((e,t)=>new $r(e,t)))}})()})(); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/23779.b38c45c0.chunk.css b/ydb/core/viewer/monitoring/static/css/23779.b38c45c0.chunk.css new file mode 100644 index 000000000000..3f09d89f5a21 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/23779.b38c45c0.chunk.css @@ -0,0 +1 @@ +.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.ydb-search{min-width:100px}.progress-viewer{align-items:center;background:var(--g-color-base-generic);border-radius:2px;color:var(--g-color-text-complementary);display:flex;font-size:var(--g-text-body-2-font-size);height:23px;justify-content:center;min-width:150px;overflow:hidden;padding:0 4px;position:relative;white-space:nowrap;z-index:0}.progress-viewer_theme_dark{color:var(--g-color-text-light-primary)}.progress-viewer_theme_dark .progress-viewer__line{opacity:.75}.progress-viewer_status_good{background-color:var(--g-color-base-positive-light)}.progress-viewer_status_good .progress-viewer__line{background-color:var(--ydb-color-status-green)}.progress-viewer_status_warning{background-color:var(--g-color-base-yellow-light)}.progress-viewer_status_warning .progress-viewer__line{background-color:var(--ydb-color-status-yellow)}.progress-viewer_status_danger{background-color:var(--g-color-base-danger-light)}.progress-viewer_status_danger .progress-viewer__line{background-color:var(--ydb-color-status-red)}.progress-viewer__line{height:100%;left:0;position:absolute;top:0}.progress-viewer__text{position:relative;z-index:1}.progress-viewer_size_xs{font-size:var(--g-text-body-2-font-size);height:20px;line-height:var(--g-text-body-2-line-height)}.progress-viewer_size_s{font-size:var(--g-text-body-1-font-size);height:28px;line-height:28px}.progress-viewer_size_m{font-size:var(--g-text-body-2-font-size);height:32px;line-height:32px}.progress-viewer_size_ns{font-size:13px;height:24px;line-height:var(--g-text-subheader-3-line-height)}.progress-viewer_size_n{font-size:var(--g-text-body-1-font-size);height:36px;line-height:36px}.progress-viewer_size_l{font-size:var(--g-text-subheader-3-font-size);height:38px;line-height:38px}.progress-viewer_size_head{font-size:var(--g-text-body-1-font-size);line-height:36px}.kv-user{color:var(--g-color-text-primary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.kv-user,.kv-user__name{display:inline-block}.kv-user__name:first-letter{color:var(--g-color-text-danger)}.gc-help-popover__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.gc-help-popover__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.g-progress{--_--empty-background-color:var(--g-color-base-generic);--_--empty-text-color:var(--g-color-text-primary);--_--filled-text-color:var(--g-color-text-primary);--_--filled-background-color:var(--g-color-base-neutral-medium);background-color:var(--g-progress-empty-background-color,var(--_--empty-background-color));border-radius:3px;margin:0 auto;overflow:hidden;position:relative;text-align:center}.g-progress__text{color:var(--g-progress-empty-text-color,var(--_--empty-text-color));position:relative}.g-progress__text,.g-progress__text-inner{box-sizing:border-box;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);padding:0 10px}.g-progress__text-inner{color:var(--g-progress-filled-text-color,var(--_--empty-text-color));height:100%;position:absolute;transition:transform .6s ease;width:100%}.g-progress__item{background-color:var(--g-progress-filled-background-color,var(--_--filled-background-color));float:left;height:100%;overflow:hidden;position:relative;transition:transform .6s ease,width .6s ease,background-color .6s ease;width:100%}[dir=rtl] .g-progress__item{float:right}.g-progress__item_theme_default{--_--filled-background-color:var(--g-color-base-neutral-medium)}.g-progress__item_theme_success{--_--filled-background-color:var(--g-color-base-positive-medium)}.g-progress__item_theme_warning{--_--filled-background-color:var(--g-color-base-warning-medium)}.g-progress__item_theme_danger{--_--filled-background-color:var(--g-color-base-danger-medium)}.g-progress__item_theme_info{--_--filled-background-color:var(--g-color-base-info-medium)}.g-progress__item_theme_misc{--_--filled-background-color:var(--g-color-base-misc-medium)}.g-progress__item_loading{animation:g-loading-animation .5s linear infinite;background-clip:padding-box;background-image:repeating-linear-gradient(-45deg,#ffffff4d,#ffffff4d 4px,#0000 0,#0000 8px);background-size:150%}.g-progress__stack{color:var(--g-color-text-light-primary);margin:0 auto;overflow:hidden;position:relative;transition:transform .6s ease;width:100%}.g-progress_size_m,.g-progress_size_m .g-progress__stack{height:20px;line-height:20px}.g-progress_size_m .g-progress__text{height:20px;margin-block-end:-20px}.g-progress_size_s,.g-progress_size_s .g-progress__stack{height:10px;line-height:10px}.g-progress_size_xs,.g-progress_size_xs .g-progress__stack{height:4px;line-height:4px}.g-progress_size_s .g-progress__text,.g-progress_size_s .g-progress__text-inner,.g-progress_size_xs .g-progress__text,.g-progress_size_xs .g-progress__text-inner{display:none}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.clusters{display:flex;flex:1 1 auto;flex-direction:column;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);overflow:auto;padding-top:15px}.clusters__autorefresh{margin-left:auto}.clusters__cluster{align-items:center;display:flex}.clusters__cluster-status{border-radius:3px;height:18px;margin-right:8px;width:18px}.clusters__cluster-status span{align-items:center;display:flex}.clusters__cluster-status_type_green{background-color:var(--ydb-color-status-green)}.clusters__cluster-status_type_yellow{background-color:var(--ydb-color-status-yellow)}.clusters__cluster-status_type_blue{background-color:var(--ydb-color-status-blue)}.clusters__cluster-status_type_red{background:var(--ydb-color-status-red)}.clusters__cluster-status_type_grey{background:var(--ydb-color-status-grey)}.clusters__cluster-status_type_orange{background:var(--ydb-color-status-orange)}.clusters__cluster-name{color:var(--g-color-text-link);text-decoration:none;white-space:normal}.clusters__cluster-versions{text-decoration:none}.clusters__cluster-version{overflow:hidden;text-overflow:ellipsis}.clusters__cluster-dc{white-space:normal}.clusters__controls{display:flex;margin-bottom:20px}.clusters__control{margin-right:15px;width:200px}.clusters__control_wide{width:300px}.clusters__empty-cell{color:var(--g-color-text-secondary)}.clusters__tooltip-content{word-break:break-all}.clusters .g-progress__item{transition:none}.clusters__aggregation,.clusters__controls{margin-left:15px;margin-right:15px}.clusters__aggregation{align-items:center;background:var(--g-color-base-generic-ultralight);border:1px solid var(--g-color-line-generic);border-radius:10px;display:flex;height:46px;margin-bottom:20px;padding:10px 20px;width:max-content}.clusters__aggregation-value-container{align-items:center;display:flex;font-size:var(--g-text-subheader-3-font-size);line-height:var(--g-text-subheader-3-line-height);max-width:230px}.clusters__aggregation-value-container:not(:last-child){margin-right:30px}.clusters__aggregation-label{color:var(--g-color-text-complementary);font-weight:200;margin-right:8px}.clusters__text{color:var(--g-color-text-primary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.clusters__text:first-letter{color:var(--g-color-text-danger)}.clusters__description{max-width:200px;white-space:pre-wrap}.clusters__table-wrapper{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto;padding-left:5px}.clusters__table-content{height:100%;overflow:auto}.clusters__table .data-table__head-row:first-child .data-table__th:first-child,.clusters__table .data-table__td:first-child{background-color:var(--g-color-base-background);border-right:1px solid var(--g-color-line-generic);left:0;position:sticky;z-index:2000}.clusters__table .data-table__row:hover .data-table__td:first-child{background-color:var(--ydb-data-table-color-hover)!important}.clusters__table .data-table__head-row:first-child .data-table__th:nth-child(0),.clusters__table .data-table__td:nth-child(0){border-right:unset;box-shadow:unset}.clusters__table .data-table__head-row:first-child .data-table__th:first-child,.clusters__table .data-table__td:first-child{box-shadow:unset}.clusters__balancer-cell{align-items:center;display:flex;flex-direction:row}.clusters__balancer-text{display:inline-block;margin-right:5px;max-width:92%;overflow:hidden;overflow-wrap:break-word!important;text-overflow:ellipsis}.clusters__balancer-icon{align-items:center;display:flex}.clusters__error{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin-left:15px}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/2512.19e3e12f.chunk.css b/ydb/core/viewer/monitoring/static/css/2512.19e3e12f.chunk.css deleted file mode 100644 index f085c20571ea..000000000000 --- a/ydb/core/viewer/monitoring/static/css/2512.19e3e12f.chunk.css +++ /dev/null @@ -1 +0,0 @@ -@charset "UTF-8";.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.ydb-nodes__search{width:238px}.ydb-nodes__show-all-wrapper{left:0;margin-bottom:15px;position:sticky}.ydb-nodes__node_unavailable{opacity:.6}.ydb-nodes__groups-wrapper{padding-right:20px}.kv-shorty-string__toggle{font-size:.85em;margin-left:2em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-resizeable-data-table{display:flex;padding-right:20px;width:max-content}.tenants__format-label{margin-right:15px}.tenants__title{text-align:center}.tenants__tooltip{animation:none!important}.tenants__search{width:238px}.tenants__tablets{padding:0!important}.tenants__tablets .tablets-viewer__grid{grid-gap:20px}.tenants__type{align-items:center;display:flex;flex-direction:row;gap:10px}.tenants__type-value{overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:min-content}.tenants__type-button{display:none}.data-table__row:hover .tenants__type-button{display:block}.tenants__name{overflow:hidden}.ydb-cluster-versions-bar{display:flex;flex-direction:column;min-width:600px}.ydb-cluster-versions-bar .g-progress{width:100%}.ydb-cluster-versions-bar__versions{display:flex;flex-flow:row wrap;margin-top:6px}.ydb-cluster-versions-bar__version-title{margin-left:3px;white-space:nowrap}.ydb-cluster-versions-bar .g-progress__stack{cursor:pointer}.g-progress{--_--empty-background-color:var(--g-color-base-generic);--_--empty-text-color:var(--g-color-text-primary);--_--filled-text-color:var(--g-color-text-primary);--_--filled-background-color:var(--g-color-base-neutral-medium);background-color:var(--g-progress-empty-background-color,var(--_--empty-background-color));border-radius:3px;margin:0 auto;overflow:hidden;position:relative;text-align:center}.g-progress__text{color:var(--g-progress-empty-text-color,var(--_--empty-text-color));position:relative}.g-progress__text,.g-progress__text-inner{box-sizing:border-box;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);padding:0 10px}.g-progress__text-inner{color:var(--g-progress-filled-text-color,var(--_--empty-text-color));height:100%;position:absolute;transition:transform .6s ease;width:100%}.g-progress__item{background-color:var(--g-progress-filled-background-color,var(--_--filled-background-color));float:left;height:100%;overflow:hidden;position:relative;transition:transform .6s ease,width .6s ease,background-color .6s ease;width:100%}[dir=rtl] .g-progress__item{float:right}.g-progress__item_theme_default{--_--filled-background-color:var(--g-color-base-neutral-medium)}.g-progress__item_theme_success{--_--filled-background-color:var(--g-color-base-positive-medium)}.g-progress__item_theme_warning{--_--filled-background-color:var(--g-color-base-warning-medium)}.g-progress__item_theme_danger{--_--filled-background-color:var(--g-color-base-danger-medium)}.g-progress__item_theme_info{--_--filled-background-color:var(--g-color-base-info-medium)}.g-progress__item_theme_misc{--_--filled-background-color:var(--g-color-base-misc-medium)}.g-progress__item_loading{animation:g-loading-animation .5s linear infinite;background-clip:padding-box;background-image:repeating-linear-gradient(-45deg,#ffffff4d,#ffffff4d 4px,#0000 0,#0000 8px);background-size:150%}.g-progress__stack{color:var(--g-color-text-light-primary);margin:0 auto;overflow:hidden;position:relative;transition:transform .6s ease;width:100%}.g-progress_size_m,.g-progress_size_m .g-progress__stack{height:20px;line-height:20px}.g-progress_size_m .g-progress__text{height:20px;margin-block-end:-20px}.g-progress_size_s,.g-progress_size_s .g-progress__stack{height:10px;line-height:10px}.g-progress_size_xs,.g-progress_size_xs .g-progress__stack{height:4px;line-height:4px}.g-progress_size_s .g-progress__text,.g-progress_size_s .g-progress__text-inner,.g-progress_size_xs .g-progress__text,.g-progress_size_xs .g-progress__text-inner{display:none}.ydb-versions-nodes-tree-title__overview{align-items:center;display:flex;justify-content:space-between;width:100%}.ydb-versions-nodes-tree-title__overview-info{align-items:center;display:flex;margin-left:25px}.ydb-versions-nodes-tree-title__overview-info>:not(:first-child){margin-left:30px}.ydb-versions-nodes-tree-title__overview-container{align-items:center;display:flex}.ydb-versions-nodes-tree-title__info-label{color:var(--g-color-text-complementary);font-weight:200}.ydb-versions-nodes-tree-title__info-label_margin_left{margin-left:5px}.ydb-versions-nodes-tree-title__info-label_margin_right{margin-right:5px}.ydb-versions-nodes-tree-title__version-color{border-radius:100%;height:16px;margin-right:10px;width:16px}.ydb-versions-nodes-tree-title__version-progress{align-items:center;display:flex;width:250px}.ydb-versions-nodes-tree-title__version-progress .g-progress{width:200px}.ydb-versions-nodes-tree-title__overview-title{align-items:center;display:flex}.ydb-versions-nodes-tree-title__clipboard-button{color:var(--g-color-text-secondary);margin-left:8px;opacity:0}.ydb-tree-view__item:hover .ydb-versions-nodes-tree-title__clipboard-button,.ydb-versions-nodes-tree-title__clipboard-button:focus-visible{opacity:1}.ydb-versions-grouped-node-tree_first-level{border:1px solid var(--g-color-line-generic);border-radius:10px;margin-bottom:10px;margin-top:10px}.ydb-versions-grouped-node-tree__dt-wrapper{margin-left:24px;margin-right:24px;overflow:auto hidden;position:relative;z-index:0}.ydb-versions-grouped-node-tree .ydb-tree-view{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-versions-grouped-node-tree .ydb-tree-view .ydb-tree-view{margin-left:24px}.ydb-versions-grouped-node-tree .tree-view_item{border:0;border-radius:10px;height:40px;margin:0;padding:0 10px!important}.ydb-versions-grouped-node-tree .tree-view_children .tree-view_item{width:100%}.ydb-versions-grouped-node-tree .g-progress__stack{cursor:pointer}.ydb-tree-view{--ydb-tree-view-level:0;font-size:13px;line-height:18px}.ydb-tree-view,.ydb-tree-view *{box-sizing:border-box}.ydb-tree-view__item{align-items:center;border-bottom:1px solid var(--g-color-line-generic-solid);cursor:pointer;display:flex;height:24px;padding-left:calc(24px*var(--ydb-tree-view-level));padding-right:3px}.ydb-tree-view__item:hover{background-color:var(--g-color-base-simple-hover)}.ydb-tree-view__item:hover .ydb-tree-view__actions{display:flex}.ydb-tree-view__item_active{background-color:var(--g-color-base-selection);font-weight:700}.ydb-tree-view__item_active:hover{background-color:var(--g-color-base-selection-hover)}.ydb-tree-view__content{align-items:center;display:flex;flex-grow:1;overflow:hidden}.ydb-tree-view__icon{align-items:center;color:var(--g-color-text-hint);display:flex;flex-shrink:0;height:24px;justify-content:center;width:24px}.ydb-tree-view__icon svg{display:block}.ydb-tree-view__text{flex-grow:1;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-tree-view__actions{align-items:center;display:none;margin-left:6px}.ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%;border:none;cursor:pointer;flex-shrink:0;height:24px;padding:0;width:24px}.g-root_theme_dark .ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%}.ydb-tree-view__arrow:focus-visible{outline:2px solid var(--g-color-line-focus)}.ydb-tree-view__arrow:not(.ydb-tree-view__arrow_collapsed){transform:rotate(90deg)}.ydb-tree-view__arrow_hidden{visibility:hidden}.ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:24px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:48px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:72px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:96px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:120px}.ydb-versions{--ydb-info-viewer-font-size:var(--g-text-body-2-font-size);--ydb-info-viewer-line-height:var(--g-text-body-2-line-height);font-size:var(--ydb-info-viewer-font-size);line-height:var(--ydb-info-viewer-line-height)}.ydb-versions__controls{align-items:center;display:flex;padding:0 0 20px}.ydb-versions__controls .ydb-versions__label{font-weight:500;margin-right:10px}.ydb-versions__controls .ydb-versions__checkbox{margin:0}.ydb-versions__controls>*{margin-right:25px}.ydb-versions__overall-wrapper{border:1px solid var(--g-color-line-generic);border-radius:10px;margin-bottom:10px;margin-top:10px;padding:20px}.ydb-versions__overall-progress{border-radius:5px;height:20px;line-height:20px}.ydb-versions__overall-progress .g-progress__stack{height:20px;line-height:20px}.tag{background:var(--g-color-base-generic);border-radius:3px;color:var(--g-color-text-primary);font-size:12px;padding:2px 5px;white-space:nowrap}.tag:last-child{margin-right:0}.tag_type_blue{background-color:var(--g-color-celestial-thunder)}.ydb-diagnostic-card{background-color:#0000;border:1px solid var(--g-color-line-generic);border-radius:8px;flex-shrink:0;padding:16px 16px 28px}.ydb-diagnostic-card_active{background-color:var(--g-color-base-selection);border-color:var(--g-color-base-info-medium)}.ydb-diagnostic-card_interactive:hover{box-shadow:0 1px 5px var(--g-color-sfx-shadow);cursor:pointer}.ydb-diagnostic-card_size_m{min-width:206px;width:206px}.ydb-diagnostic-card_size_l{min-width:289px;width:289px}.ydb-diagnostic-card_size_s{min-width:134px;width:134px}.ydb-doughnut-metrics{--doughnut-border:11px;--doughnut-color:var(--ydb-color-status-green)}.ydb-doughnut-metrics__doughnut{aspect-ratio:1;background-color:var(--doughnut-color);border-radius:50%;position:relative;width:172px}.ydb-doughnut-metrics__doughnut:before{aspect-ratio:1;background-color:var(--g-color-base-background);border-radius:50%;content:"";display:block;height:calc(100% - var(--doughnut-border)*2);transform:translate(var(--doughnut-border),var(--doughnut-border))}.ydb-doughnut-metrics__doughnut_status_warning{--doughnut-color:var(--ydb-color-status-yellow)}.ydb-doughnut-metrics__doughnut_status_danger{--doughnut-color:var(--ydb-color-status-red)}.ydb-doughnut-metrics__text-wrapper{--wrapper-indent:calc(var(--doughnut-border) + 5px);align-items:center;aspect-ratio:1;display:flex;flex-direction:column;justify-content:center;position:absolute;right:var(--wrapper-indent);text-align:center;top:var(--wrapper-indent);width:calc(100% - var(--wrapper-indent)*2)}.ydb-doughnut-metrics__value{bottom:20px;position:absolute}.ydb-doughnut-metrics__legend{height:50%;white-space:pre-wrap}.ydb-disk-groups-stats{cursor:pointer}.ydb-disk-groups-stats__popup-content{padding:var(--g-spacing-3)}.gc-help-popover__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.gc-help-popover__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.gc-definition-list__list{margin:0}.gc-definition-list__group-title{margin-block-end:var(--g-spacing-3)}.gc-definition-list__group-title:not(:first-of-type){margin-block-start:var(--g-spacing-5)}.gc-definition-list__item{align-items:baseline;display:flex;gap:var(--g-spacing-1)}.gc-definition-list__item+.gc-definition-list__item{margin-block-start:var(--g-spacing-4)}.gc-definition-list__item_grouped+.gc-definition-list__item_grouped{margin-block-start:var(--g-spacing-3)}.gc-definition-list_margin:not(:first-of-type){margin-block-start:var(--g-spacing-5)}.gc-definition-list__term-container{align-items:baseline;display:flex;flex:0 0 auto;max-width:300px;overflow:hidden;position:relative;width:300px}.gc-definition-list__term-wrapper{color:var(--g-color-text-secondary);flex:0 1 auto;overflow:hidden;position:relative;text-overflow:ellipsis;white-space:nowrap}.gc-definition-list__term-container_multiline .gc-definition-list__term-wrapper{white-space:unset}.gc-definition-list__term-container_multiline .gc-definition-list__item-note-tooltip{position:absolute}.gc-definition-list__dots{border-block-end:1px dotted var(--g-color-line-generic-active);box-sizing:border-box;flex:1 0 auto;margin:0 2px;min-width:40px}.gc-definition-list__dots_with-note{margin-inline-start:15px;min-width:25px}.gc-definition-list__definition{flex:0 1 auto;margin:0}.gc-definition-list_responsive .gc-definition-list__term-container{flex:1 0 auto}.gc-definition-list__copy-container{align-items:center;display:inline-flex;margin-inline-end:calc(var(--g-spacing-7)*-1);padding-inline-end:var(--g-spacing-7);position:relative}.gc-definition-list__copy-container:hover .gc-definition-list__copy-button{opacity:1}.gc-definition-list__copy-container_icon-inside{margin-inline-end:unset;padding-inline-end:unset}.gc-definition-list__copy-container_icon-inside .gc-definition-list__copy-button{inset-block-start:0}.gc-definition-list__copy-button{display:inline-block;inset-inline-end:0;margin-inline-start:10px;opacity:0;position:absolute}.gc-definition-list__copy-button:focus-visible{opacity:1}.gc-definition-list_vertical .gc-definition-list__term-container{flex:1 0 auto}.gc-definition-list_vertical .gc-definition-list__item{flex-direction:column;gap:var(--g-spacing-half)}.gc-definition-list_vertical .gc-definition-list__item+.gc-definition-list__item{margin-block-start:var(--g-spacing-3)}.gc-definition-list_vertical .gc-definition-list__group-title:not(:first-of-type),.gc-definition-list_vertical .gc-definition-list_margin:not(:first-of-type){margin-block-start:var(--g-spacing-8)}.ydb-cluster-dashboard{left:0;padding-top:16px;position:sticky}.ydb-cluster-dashboard__error{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-cluster-dashboard__card{display:flex;flex-direction:column;height:252px}.ydb-cluster-dashboard__card_size_s{height:unset}.ydb-cluster-dashboard__card_size_l{height:unset;width:100%}.ydb-cluster-dashboard__skeleton-wrapper{border:unset;padding:unset}.ydb-cluster-dashboard__doughnut{margin-top:auto}.ydb-cluster-dashboard__cards{display:flex}.ydb-cluster-dashboard__card-title{margin-bottom:var(--g-spacing-2)}.ydb-cluster-dashboard__skeleton{height:100%}.ydb-cluster-dashboard__cards-container{display:grid;gap:var(--g-spacing-4);grid-auto-flow:column dense;grid-template-columns:repeat(2,max-content);grid-template-rows:repeat(2,118px)}.ydb-cluster-dashboard__double-height{grid-row:span 2}.ydb-info-viewer-skeleton{display:flex;flex-direction:column;gap:16px}.ydb-info-viewer-skeleton__row{align-items:flex-start;display:flex}.ydb-info-viewer-skeleton__row,.ydb-info-viewer-skeleton__row .g-skeleton{min-height:var(--g-text-body-2-font-size)}.ydb-info-viewer-skeleton__label{align-items:baseline;display:flex;flex:0 1 auto;width:200px}.ydb-info-viewer-skeleton__label__text{width:100px}.ydb-info-viewer-skeleton__label__dots{border-bottom:1px dotted var(--g-color-text-secondary);margin:0 2px;width:100px}.ydb-info-viewer-skeleton__value{max-width:20%;min-width:200px}.ydb-nodes-state{--entity-state-border-color:var(--g-color-base-misc-heavy);--entity-state-background-color:var(--g-color-base-misc-light);--entity-state-fill-color:var(--g-color-base-misc-medium);--entity-state-font-color:var(--g-color-text-primary);align-items:center;background-color:var(--entity-state-background-color);border-radius:var(--g-spacing-1);color:var(--entity-state-font-color);display:flex;height:20px;justify-content:center;min-width:26px;padding:0 var(--g-spacing-1);width:max-content}.ydb-nodes-state_green{--entity-state-font-color:var(--g-color-text-positive);--entity-state-border-color:var(--g-color-base-positive-heavy);--entity-state-background-color:var(--g-color-base-positive-light);--entity-state-fill-color:var(--g-color-base-positive-medium)}.ydb-nodes-state_blue{--entity-state-font-color:var(--g-color-text-info);--entity-state-border-color:var(--g-color-base-info-heavy);--entity-state-background-color:var(--g-color-base-info-light);--entity-state-fill-color:var(--g-color-base-info-medium)}.ydb-nodes-state_yellow{--entity-state-font-color:var(--g-color-text-warning);--entity-state-border-color:var(--g-color-base-warning-heavy);--entity-state-background-color:var(--g-color-base-yellow-light);--entity-state-fill-color:var(--g-color-base-yellow-medium)}.ydb-nodes-state_orange{--entity-state-font-color:var(--g-color-private-orange-500);--entity-state-border-color:var(--ydb-color-status-orange);--entity-state-background-color:var(--g-color-private-orange-100);--entity-state-fill-color:var(--g-color-private-orange-300)}.ydb-nodes-state_red{--entity-state-font-color:var(--g-color-text-danger);--entity-state-border-color:var(--g-color-base-danger-heavy);--entity-state-background-color:var(--g-color-base-danger-light);--entity-state-fill-color:var(--g-color-base-danger-medium)}.ydb-nodes-state__grey{--entity-state-font-color:var(--g-color-text-secondary);--entity-state-border-color:var(--g-color-line-generic-hover)}.cluster-info{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);padding:20px 0}.cluster-info__skeleton{margin-top:5px}.cluster-info__section-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-2-line-height);margin:var(--g-spacing-1) 0 var(--g-spacing-3)}.cluster-info__dc{height:20px}.cluster-info__clipboard-button{align-items:center;display:flex;margin-left:5px}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-cluster{flex-grow:1;height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-cluster__header{left:0;padding:20px 0;position:sticky}.ydb-cluster__title{font-size:var(--g-text-header-1-font-size);font-weight:var(--g-text-header-font-weight);line-height:var(--g-text-header-1-line-height)}.ydb-cluster__title-skeleton{height:var(--g-text-header-1-line-height);min-width:200px;width:20%}.ydb-cluster__tabs-sticky-wrapper{background-color:var(--g-color-base-background);left:0;margin-right:-40px;margin-top:20px;padding-left:20px;padding-right:40px;position:sticky;top:0;transform:translateX(-20px);z-index:3}.ydb-cluster__tabs{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic);display:flex}.ydb-cluster__sticky-wrapper{left:0;position:sticky;top:66px;z-index:4}.ydb-cluster__auto-refresh-control{background-color:var(--g-color-base-background);float:right;margin-top:-46px}.ydb-cluster .ydb-table-with-controls-layout__controls-wrapper{top:40px}.ydb-cluster__tablets .data-table__sticky_moving{top:40px!important}.ydb-cluster .ydb-table-with-controls-layout{--data-table-sticky-top-offset:102px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/29006.d52dfb31.chunk.css b/ydb/core/viewer/monitoring/static/css/29006.d52dfb31.chunk.css new file mode 100644 index 000000000000..04cd0bfc9591 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/29006.d52dfb31.chunk.css @@ -0,0 +1 @@ +.kv-split{display:flex;height:100%;outline:none;-webkit-user-select:text;user-select:text;z-index:0}.kv-split.horizontal{flex-direction:row}.kv-split.vertical{flex-direction:column;min-height:100%;width:100%}.kv-split .gutter{background:var(--g-color-base-background);position:relative;z-index:10}.kv-split .gutter:after{background-color:var(--g-color-base-generic-ultralight);content:"";inset:0;position:absolute}.kv-split .gutter.active:after,.kv-split .gutter:hover:after{background-color:var(--g-color-line-generic-hover);transition:background-color 1s ease}.kv-split .gutter.disabled{display:none}.kv-split .gutter.gutter-vertical{cursor:row-resize;height:8px;width:100%}.kv-split .gutter.gutter-vertical:before{border-color:var(--g-color-base-generic-hover);border-style:solid;border-width:1px 0;content:"";height:4px;left:50%;position:absolute;top:50%;transform:translate(-50%,-50%);width:16px}.kv-split .gutter.gutter-horizontal{cursor:col-resize;height:100%;width:8px}.kv-split .gutter.gutter-horizontal:before{border-color:var(--g-color-base-generic-hover);border-style:solid;border-width:0 1px;content:"";height:16px;left:50%;position:absolute;top:50%;transform:translate(-50%,-50%);width:4px}.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.ydb-drawer__drawer-container{height:100%;overflow:hidden;position:relative}.ydb-drawer__item{height:100%;z-index:4}.ydb-drawer__controls{margin-left:auto}.ydb-drawer__header-wrapper{background-color:var(--g-color-base-background);left:0;padding:var(--g-spacing-4) var(--g-spacing-4) 0 var(--g-spacing-4);position:sticky;top:0;z-index:3}.ydb-drawer__content-wrapper{display:flex;flex-direction:column;height:100%;margin-left:var(--g-spacing-2);overflow:auto}.ydb-drawer__click-handler{display:contents}.histogram{display:flex;flex:1 1 auto}.histogram__chart{align-items:baseline;border-bottom:1px solid var(--g-color-base-generic);border-left:1px solid var(--g-color-base-generic);display:flex;height:300px;margin-left:50px;margin-top:30px;position:relative;width:800px}.histogram__x-min{left:-3px}.histogram__x-max,.histogram__x-min{bottom:-25px;color:var(--g-color-text-secondary);position:absolute}.histogram__x-max{right:0}.histogram__y-min{bottom:-7px;left:-30px;width:20px}.histogram__y-max,.histogram__y-min{color:var(--g-color-text-secondary);position:absolute;text-align:right}.histogram__y-max{left:-60px;top:-5px;width:50px}.histogram__item{cursor:pointer;margin-right:.5%;width:1.5%}.heatmap{display:flex;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto}.heatmap__limits{align-items:center;display:flex;margin-left:20px}.heatmap__limits-block{display:flex;margin-right:10px}.heatmap__limits-title{color:var(--g-color-text-secondary);margin-right:5px}.heatmap__row{align-items:center}.heatmap__row_overall{margin:15px 20px}.heatmap__row_overall .g-progress{margin:0;width:300px}.heatmap__label{font-size:var(--g-text-body-2-font-size);font-weight:500;line-height:var(--g-text-body-2-line-height);margin-right:16px;text-transform:uppercase}.heatmap__label_overall{margin-right:15px}.heatmap__items{overflow:auto}.heatmap__canvas-container{cursor:pointer;overflow:auto}.heatmap__filters{align-items:center;display:flex;margin:0 0 10px}.heatmap__filter-control{margin-right:10px;max-width:200px;min-width:100px}.heatmap__filter-control:last-child{margin-right:0}.heatmap__histogram-checkbox,.heatmap__sort-checkbox{margin-left:10px}.heatmap__row{display:flex}.heatmap .tablet,.heatmap__row{margin-bottom:2px}.table-skeleton__wrapper{width:100%}.table-skeleton__wrapper_hidden{visibility:hidden}.table-skeleton__row{align-items:center;display:flex;height:var(--data-table-row-height)}.table-skeleton__row .g-skeleton{height:var(--g-text-body-2-line-height)}.table-skeleton__col-1{margin-right:5%;width:10%}.table-skeleton__col-2{margin-right:5%;width:7%}.table-skeleton__col-3,.table-skeleton__col-4{margin-right:5%;width:5%}.table-skeleton__col-5{width:20%}.table-skeleton__col-full{width:100%}.ydb-table-with-controls-layout{--data-table-sticky-header-offset:62px;box-sizing:border-box;display:inline-block;min-width:100%}.ydb-table-with-controls-layout_full-height{min-height:calc(100% - var(--sticky-tabs-height, 0px))}.ydb-table-with-controls-layout__controls-wrapper{background-color:var(--g-color-base-background);box-sizing:border-box;left:0;position:sticky;top:0;width:100%;z-index:3}.ydb-table-with-controls-layout__controls{align-items:center;background-color:var(--g-color-base-background);display:flex;gap:12px;height:62px;left:0;padding:16px 0 18px;position:sticky;top:0;width:max-content;z-index:3}.ydb-table-with-controls-layout__table{position:relative;z-index:2}.ydb-table-with-controls-layout .ydb-paginated-table__head{top:var(--data-table-sticky-header-offset,62px)}.ydb-table-with-controls-layout .data-table__sticky_moving{top:var(--data-table-sticky-header-offset,62px)!important}.ydb-table-group{border:1px solid var(--g-color-line-generic);border-radius:var(--g-spacing-2);display:flex;flex-direction:column;margin-bottom:20px;min-width:100%;width:max-content}.ydb-table-group__button{background:unset;border:unset;cursor:pointer;padding:8px 0}.ydb-table-group__title-wrapper{align-items:center;display:flex;flex-direction:row;gap:var(--g-spacing-2);justify-content:flex-start;left:0;padding-left:20px;position:sticky;width:max-content}.ydb-table-group__title{display:flex;flex-direction:row;gap:var(--g-spacing-4)}.ydb-table-group__count{display:flex;flex-direction:row;gap:var(--g-spacing-3)}.ydb-table-group__content{padding:12px 0 20px 20px}.ydb-search{min-width:100px}.ydb-paginated-table{--paginated-table-cell-vertical-padding:5px;--paginated-table-cell-horizontal-padding:10px;--paginated-table-border-color:var(--g-color-base-generic-hover);--paginated-table-hover-color:var(--g-color-base-simple-hover-solid);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);width:100%}.ydb-paginated-table__table{border-collapse:initial;border-spacing:0;max-width:100%;table-layout:fixed;width:max-content}.ydb-paginated-table__table th{padding:0}.ydb-paginated-table__row{position:relative;transform:translateZ(0);z-index:1}.ydb-paginated-table__row:hover{background:var(--paginated-table-hover-color)}.ydb-paginated-table__row_empty:hover{background-color:initial}.ydb-paginated-table__head{background-color:var(--g-color-base-background);left:0;position:sticky;top:0;z-index:2}.ydb-paginated-table__sort-icon-container{color:inherit;display:flex;justify-content:center}.ydb-paginated-table__sort-icon-container_shadow{opacity:.15}.ydb-paginated-table__sort-icon_desc{transform:rotate(180deg)}.ydb-paginated-table__head-cell-wrapper{border-bottom:1px solid var(--paginated-table-border-color);display:table-cell;overflow-x:hidden;position:relative}.ydb-paginated-table__head-cell{align-items:center;cursor:default;display:flex;flex-direction:row;font-weight:700;gap:var(--g-spacing-2);max-width:100%;padding:var(--paginated-table-cell-vertical-padding) var(--paginated-table-cell-horizontal-padding);width:100%}.ydb-paginated-table__head-cell_align_left{justify-content:left;text-align:left}.ydb-paginated-table__head-cell_align_center{justify-content:center;text-align:center}.ydb-paginated-table__head-cell_align_right{justify-content:right;text-align:right}.ydb-paginated-table__head-cell_align_right .ydb-paginated-table__head-cell-content-container{flex-direction:row-reverse}.ydb-paginated-table__head-cell_sortable{cursor:pointer}.ydb-paginated-table__head-cell_sortable.ydb-paginated-table__head-cell_align_right{flex-direction:row-reverse}.ydb-paginated-table__head-cell-note{display:flex}.ydb-paginated-table__head-cell-content{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-paginated-table__head-cell-content-container{display:inline-flex;gap:var(--g-spacing-1);overflow:hidden}.ydb-paginated-table__head-cell-content-container .g-help-mark__button{align-items:center;display:inline-flex}.ydb-paginated-table__row-cell{border-bottom:1px solid var(--paginated-table-border-color);display:table-cell;max-width:100%;overflow-x:hidden;padding:var(--paginated-table-cell-vertical-padding) var(--paginated-table-cell-horizontal-padding);text-overflow:ellipsis;vertical-align:middle;white-space:nowrap;width:100%}.ydb-paginated-table__row-cell_align_left{text-align:left}.ydb-paginated-table__row-cell_align_center{text-align:center}.ydb-paginated-table__row-cell_align_right{text-align:right}.ydb-paginated-table__resize-handler{background-color:var(--g-color-base-generic);cursor:col-resize;height:100%;position:absolute;right:0;top:0;visibility:hidden;width:6px}.ydb-paginated-table__head-cell-wrapper:hover>.ydb-paginated-table__resize-handler,.ydb-paginated-table__resize-handler_resizing{visibility:visible}.ydb-paginated-table__resizeable-table-container{padding-right:20px;width:max-content}.ydb-paginated-table__row-skeleton:after{display:none!important}.ydb-nodes__search{width:238px}.ydb-nodes__show-all-wrapper{left:0;margin-bottom:15px;position:sticky}.ydb-nodes__node_unavailable{opacity:.6}.hover-popup{padding:var(--g-spacing-3)}.progress-viewer{align-items:center;background:var(--g-color-base-generic);border-radius:2px;color:var(--g-color-text-complementary);display:flex;font-size:var(--g-text-body-2-font-size);height:23px;justify-content:center;min-width:150px;overflow:hidden;padding:0 4px;position:relative;white-space:nowrap;z-index:0}.progress-viewer_theme_dark{color:var(--g-color-text-light-primary)}.progress-viewer_theme_dark .progress-viewer__line{opacity:.75}.progress-viewer_status_good{background-color:var(--g-color-base-positive-light)}.progress-viewer_status_good .progress-viewer__line{background-color:var(--ydb-color-status-green)}.progress-viewer_status_warning{background-color:var(--g-color-base-yellow-light)}.progress-viewer_status_warning .progress-viewer__line{background-color:var(--ydb-color-status-yellow)}.progress-viewer_status_danger{background-color:var(--g-color-base-danger-light)}.progress-viewer_status_danger .progress-viewer__line{background-color:var(--ydb-color-status-red)}.progress-viewer__line{height:100%;left:0;position:absolute;top:0}.progress-viewer__text{position:relative;z-index:1}.progress-viewer_size_xs{font-size:var(--g-text-body-2-font-size);height:20px;line-height:var(--g-text-body-2-line-height)}.progress-viewer_size_s{font-size:var(--g-text-body-1-font-size);height:28px;line-height:28px}.progress-viewer_size_m{font-size:var(--g-text-body-2-font-size);height:32px;line-height:32px}.progress-viewer_size_ns{font-size:13px;height:24px;line-height:var(--g-text-subheader-3-line-height)}.progress-viewer_size_n{font-size:var(--g-text-body-1-font-size);height:36px;line-height:36px}.progress-viewer_size_l{font-size:var(--g-text-subheader-3-font-size);height:38px;line-height:38px}.progress-viewer_size_head{font-size:var(--g-text-body-1-font-size);line-height:36px}.memory-viewer{min-width:150px;padding:0 var(--g-spacing-1);position:relative;z-index:0}.memory-viewer__progress-container{background:var(--g-color-base-generic);border-radius:2px;height:20px;overflow:hidden;position:relative}.memory-viewer__container{display:flex;padding:2px 0}.memory-viewer__legend{border-radius:2px;bottom:2px;height:20px;position:absolute;width:20px}.memory-viewer__legend_type_AllocatorCachesMemory{background-color:var(--g-color-base-utility-medium-hover)}.memory-viewer__legend_type_SharedCacheConsumption{background-color:var(--g-color-base-info-medium-hover)}.memory-viewer__legend_type_MemTableConsumption{background-color:var(--g-color-base-warning-medium-hover)}.memory-viewer__legend_type_QueryExecutionConsumption{background-color:var(--g-color-base-positive-medium-hover)}.memory-viewer__legend_type_Other{background-color:var(--g-color-base-generic-medium-hover)}.memory-viewer__segment{height:100%;position:absolute}.memory-viewer__segment_type_AllocatorCachesMemory{background-color:var(--g-color-base-utility-medium-hover)}.memory-viewer__segment_type_SharedCacheConsumption{background-color:var(--g-color-base-info-medium-hover)}.memory-viewer__segment_type_MemTableConsumption{background-color:var(--g-color-base-warning-medium-hover)}.memory-viewer__segment_type_QueryExecutionConsumption{background-color:var(--g-color-base-positive-medium-hover)}.memory-viewer__segment_type_Other{background-color:var(--g-color-base-generic-medium-hover)}.memory-viewer__name{padding-left:28px}.memory-viewer_theme_dark{color:var(--g-color-text-light-primary)}.memory-viewer_theme_dark .memory-viewer__segment{opacity:.75}.memory-viewer_status_good .memory-viewer__progress-container{background-color:var(--g-color-base-positive-light)}.memory-viewer_status_warning .memory-viewer__progress-container{background-color:var(--g-color-base-yellow-light)}.memory-viewer_status_danger .memory-viewer__progress-container{background-color:var(--g-color-base-danger-light)}.memory-viewer__text{align-items:center;display:flex;justify-content:center}.ydb-pool-bar{border:1px solid;border-radius:1px;cursor:pointer;height:20px;margin-right:2px;position:relative;width:6px}.ydb-pool-bar__popup-content{padding:10px;width:170px}.ydb-pool-bar:last-child{margin-right:0}.ydb-pool-bar_type_normal{border-color:var(--ydb-color-status-green)}.ydb-pool-bar_type_warning{border-color:var(--ydb-color-status-yellow)}.ydb-pool-bar_type_danger{border-color:var(--ydb-color-status-red)}.ydb-pool-bar__value{bottom:0;min-height:1px;position:absolute;width:100%}.ydb-pool-bar__value_type_normal{background-color:var(--ydb-color-status-green)}.ydb-pool-bar__value_type_warning{background-color:var(--ydb-color-status-yellow)}.ydb-pool-bar__value_type_danger{background-color:var(--ydb-color-status-red)}.ydb-pools-graph{display:flex}.tablets-statistic{align-items:center;display:flex;gap:2px}.tablets-statistic__tablet{border:1px solid;border-radius:2px;color:var(--g-color-text-secondary);display:inline-block;font-size:11px;height:20px;line-height:20px;padding:0 4px;text-align:center;text-decoration:none;text-transform:uppercase}.tablets-statistic__tablet_state_green{background-color:var(--g-color-base-positive-light);color:var(--g-color-text-positive)}.tablets-statistic__tablet_state_yellow{background-color:var(--g-color-base-warning-light);color:var(--g-color-text-warning)}.tablets-statistic__tablet_state_blue{background-color:var(--g-color-base-info-light);color:var(--g-color-text-info)}.tablets-statistic__tablet_state_orange{background-color:var(--g-color-base-warning-light);color:var(--g-color-text-warning-heavy)}.tablets-statistic__tablet_state_red{background:var(--g-color-base-danger-light);color:var(--g-color-text-danger)}.tablets-statistic__tablet_state_grey{border:1px solid var(--g-color-line-generic-hover);color:var(--g-color-text-secondary)}.ydb-nodes-columns__column-cpu,.ydb-nodes-columns__column-ram{min-width:40px}.operations__search{width:220px}.kv-shorty-string__toggle{font-size:.85em;margin-left:1em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.storage-disk-progress-bar{--progress-bar-full-height:var(--g-text-body-3-line-height);--progress-bar-compact-height:12px;--entity-state-border-color:var(--g-color-base-misc-heavy);--entity-state-background-color:var(--g-color-base-misc-light);--entity-state-fill-color:var(--g-color-base-misc-medium);--entity-state-font-color:var(--g-color-text-primary);background-color:var(--entity-state-background-color);border:1px solid var(--entity-state-border-color);border-radius:4px;color:var(--g-color-text-primary);height:var(--progress-bar-full-height);min-width:50px;position:relative;text-align:center;z-index:0}.storage-disk-progress-bar_green{--entity-state-font-color:var(--g-color-text-positive);--entity-state-border-color:var(--g-color-base-positive-heavy);--entity-state-background-color:var(--g-color-base-positive-light);--entity-state-fill-color:var(--g-color-base-positive-medium)}.storage-disk-progress-bar_blue{--entity-state-font-color:var(--g-color-text-info);--entity-state-border-color:var(--g-color-base-info-heavy);--entity-state-background-color:var(--g-color-base-info-light);--entity-state-fill-color:var(--g-color-base-info-medium)}.storage-disk-progress-bar_yellow{--entity-state-font-color:var(--g-color-text-warning);--entity-state-border-color:var(--g-color-base-warning-heavy);--entity-state-background-color:var(--g-color-base-yellow-light);--entity-state-fill-color:var(--g-color-base-yellow-medium)}.storage-disk-progress-bar_orange{--entity-state-font-color:var(--g-color-private-orange-500);--entity-state-border-color:var(--ydb-color-status-orange);--entity-state-background-color:var(--g-color-private-orange-100);--entity-state-fill-color:var(--g-color-private-orange-300)}.storage-disk-progress-bar_red{--entity-state-font-color:var(--g-color-text-danger);--entity-state-border-color:var(--g-color-base-danger-heavy);--entity-state-background-color:var(--g-color-base-danger-light);--entity-state-fill-color:var(--g-color-base-danger-medium)}.storage-disk-progress-bar__grey{--entity-state-font-color:var(--g-color-text-secondary);--entity-state-border-color:var(--g-color-line-generic-hover)}.storage-disk-progress-bar_compact{border-radius:2px;height:var(--progress-bar-compact-height);min-width:0}.storage-disk-progress-bar_faded{background-color:unset}.storage-disk-progress-bar_inactive{opacity:.5}.storage-disk-progress-bar_empty{background-color:unset;border-style:dashed;color:var(--g-color-text-hint)}.storage-disk-progress-bar__fill-bar{background-color:var(--entity-state-fill-color);border-radius:3px 0 0 3px;height:100%;left:0;position:absolute;top:0}.storage-disk-progress-bar__fill-bar_faded{background-color:var(--entity-state-background-color)}.storage-disk-progress-bar__fill-bar_compact{border-radius:1px}.storage-disk-progress-bar__fill-bar_inverted{border-radius:0 3px 3px 0;left:auto;right:0}.storage-disk-progress-bar__title{color:inherit;font-size:var(--g-text-body-1-font-size);line-height:calc(var(--progress-bar-full-height) - 2px);position:relative;z-index:2}.vdisk-storage-popup .info-viewer+.info-viewer{border-top:1px solid var(--g-color-line-generic);margin-top:8px;padding-top:8px}.vdisk-storage-popup__donor-label{margin-bottom:8px}.ydb-vdisk-component{border-radius:4px}.ydb-vdisk-component__content{border-radius:4px;display:block}.pdisk-storage{--pdisk-vdisk-width:3px;--pdisk-gap-width:2px;display:flex;flex-direction:column;justify-content:flex-end;min-width:var(--pdisk-min-width);position:relative}.pdisk-storage__content{border-radius:4px;display:block;flex:1 1;position:relative}.pdisk-storage__vdisks{display:flex;flex:0 0 auto;gap:var(--pdisk-gap-width);margin-bottom:4px;white-space:nowrap}.pdisk-storage__vdisks-item{flex:0 0 var(--pdisk-vdisk-width);min-width:var(--pdisk-vdisk-width)}.data-table__row:hover .pdisk-storage__vdisks-item .stack__layer{background:var(--ydb-data-table-color-hover)}.pdisk-storage__donors-stack{--ydb-stack-offset-x:0px;--ydb-stack-offset-y:-2px;--ydb-stack-offset-x-hover:0px;--ydb-stack-offset-y-hover:-7px}.pdisk-storage__media-type{color:var(--g-color-text-secondary);font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height);position:absolute;right:4px;top:50%;transform:translateY(-50%)}.ydb-storage-disks{align-items:center;display:flex;flex-direction:row;gap:20px;width:max-content}.ydb-storage-disks__pdisks-wrapper{display:flex;flex-direction:row;justify-content:left;width:max-content}.ydb-storage-disks__vdisk-item{flex-basis:8px;flex-shrink:0}.ydb-storage-disks__vdisk-progress-bar{--progress-bar-compact-height:18px;border-radius:4px}.ydb-storage-disks__pdisk-item{margin-right:4px;min-width:80px}.ydb-storage-disks__pdisk-item_with-dc-margin{margin-right:12px}.ydb-storage-disks__pdisk-item:last-child{margin-right:0}.ydb-storage-disks__pdisk-progress-bar{--progress-bar-full-height:20px;padding-left:var(--g-spacing-2);text-align:left}.stack{--ydb-stack-base-z-index:100;--ydb-stack-offset-x:4px;--ydb-stack-offset-y:4px;--ydb-stack-offset-x-hover:4px;--ydb-stack-offset-y-hover:6px;position:relative}.stack__layer{background:var(--g-color-base-background);transition:transform .1s ease-out}.stack__layer:first-child{position:relative;z-index:var(--ydb-stack-base-z-index)}.stack__layer+.stack__layer{height:100%;left:0;position:absolute;top:0;transform:translate(calc(var(--ydb-stack-level)*var(--ydb-stack-offset-x)),calc(var(--ydb-stack-level)*var(--ydb-stack-offset-y)));width:100%;z-index:calc(var(--ydb-stack-base-z-index) - var(--ydb-stack-level))}.stack:hover .stack__layer:first-child{transform:translate(calc(var(--ydb-stack-offset-x-hover)*-1),calc(var(--ydb-stack-offset-y-hover)*-1))}.stack:hover .stack__layer+.stack__layer{transform:translate(calc(var(--ydb-stack-level)*var(--ydb-stack-offset-x-hover)*2 - var(--ydb-stack-offset-x-hover)),calc(var(--ydb-stack-level)*var(--ydb-stack-offset-y-hover)*2 - var(--ydb-stack-offset-y-hover)))}.ydb-storage-vdisks__wrapper{display:flex}.ydb-storage-vdisks__item{margin-right:6px;width:90px}.ydb-storage-vdisks__item_with-dc-margin{margin-right:12px}.ydb-storage-vdisks__item:last-child{margin-right:0}.data-table__row:hover .ydb-storage-vdisks__item .stack__layer{background:var(--ydb-data-table-color-hover)}.ydb-storage-groups-columns__disks-column,.ydb-storage-groups-columns__vdisks-column{overflow:visible}.ydb-storage-groups-columns__pool-name-wrapper{direction:rtl;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-storage-groups-columns__pool-name{unicode-bidi:plaintext}.ydb-storage-groups-columns__group-id{font-weight:500;margin-right:var(--g-spacing-1)}.global-storage__search{width:238px}.global-storage__table .g-tooltip{height:var(--g-text-body-2-line-height)!important}.global-storage .entity-status{justify-content:center}.ydb-storage-nodes__node_unavailable{opacity:.6}.ydb-storage-nodes-columns__pdisks-column{overflow:visible}.ydb-storage-nodes-columns__pdisks-wrapper{display:flex;gap:10px;height:40px}.ydb-storage-nodes-columns__pdisks-item{display:flex;flex-shrink:0}.schema-viewer__keys{display:inline-block;padding-bottom:var(--g-spacing-4);padding-left:10px}.schema-viewer__keys-values{color:var(--g-color-text-complementary);display:inline;font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height)}.schema-viewer__keys-header{color:var(--g-color-text-primary);display:inline;font-size:var(--g-text-subheader-1-font-size);font-weight:700;line-height:var(--g-text-subheader-1-line-height);white-space:nowrap}.schema-viewer__keys-label{cursor:pointer}.schema-viewer__keys-wrapper{left:0;position:sticky;width:100%;z-index:1}.schema-viewer__keys+.schema-viewer__keys{margin-left:var(--g-spacing-8)}.schema-viewer__keys_summary+.schema-viewer__keys_summary{margin-left:0}.schema-viewer__popup-content{padding:var(--g-spacing-2) var(--g-spacing-4)}.schema-viewer__popup-item{padding-bottom:var(--g-spacing-2)}.schema-viewer__popup-item:last-child{padding-bottom:0}.schema-viewer__more-badge{margin-left:var(--g-spacing-1)}.schema-viewer__key-icon{margin-left:var(--g-spacing-half);position:absolute;top:3.5px;vertical-align:initial}.schema-viewer__id-wrapper{display:inline-block;padding-right:var(--g-spacing-1);position:relative}.ydb-diagnostics-configs__icon-touched{color:var(--g-color-text-secondary);cursor:default!important;line-height:1}.speed-multimeter{display:flex;width:100%}.speed-multimeter__content{display:flex;flex-direction:row;flex-grow:1;justify-content:flex-end;line-height:22px}.speed-multimeter__displayed-value{display:flex;flex-direction:row;justify-content:flex-end;margin-right:10px}.speed-multimeter__bars{align-items:flex-start;display:flex;flex-direction:column;margin-right:5px;overflow:hidden;width:32px}.speed-multimeter__bar-container{height:6px;width:100%}.speed-multimeter__bar-container_highlighted{background:var(--g-color-line-generic)}.speed-multimeter__bar{height:100%;min-width:2px}.speed-multimeter__bar_color_light{background:var(--g-color-base-info-medium)}.speed-multimeter__bar_color_dark{background:var(--g-color-base-info-heavy)}.speed-multimeter__bar-container+.speed-multimeter__bar-container{margin-top:2px}.speed-multimeter__popover-container{align-items:center;display:flex;justify-content:center}.speed-multimeter__popover-content{padding:10px}.speed-multimeter__popover-header{display:block;font-size:18px;line-height:24px;margin-bottom:7px}.speed-multimeter__popover-row{display:block;font-size:13px;line-height:18px}.speed-multimeter__popover-row_color_primary{color:var(--g-color-text-primary)}.speed-multimeter__popover-row_color_secondary{color:var(--g-color-text-secondary)}.ydb-diagnostics-consumers-topic-stats{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-diagnostics-consumers-topic-stats__wrapper{border-left:1px solid var(--g-color-line-generic);display:flex;flex-direction:row;padding-left:16px}.ydb-diagnostics-consumers-topic-stats__item{display:flex;flex-direction:column;margin-right:20px}.ydb-diagnostics-consumers-topic-stats__label{color:var(--g-color-text-secondary);margin-bottom:4px}.ydb-diagnostics-consumers-topic-stats__value{align-items:center;display:flex;height:30px;justify-content:flex-start}.ydb-lag-popover-content__text{margin-bottom:10px}.ydb-lag-popover-content_type_read{max-width:280px}.ydb-lag-popover-content_type_write{max-width:220px}.ydb-diagnostics-consumers-columns-header__lags{white-space:nowrap}.ydb-diagnostics-consumers-columns__lags-header{text-align:center}.ydb-diagnostics-consumers{display:flex;flex-grow:1;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto}.ydb-diagnostics-consumers__controls{align-items:center;display:flex;gap:12px;padding:16px 0 18px}.ydb-diagnostics-consumers__search{width:238px}.ydb-diagnostics-consumers__table-wrapper{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.ydb-diagnostics-consumers__table-content{height:100%;overflow:auto}.ydb-diagnostics-consumers__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-consumers__table .data-table__td:first-child{background-color:var(--g-color-base-background);border-right:1px solid var(--g-color-line-generic);left:0;position:sticky;z-index:2000}.ydb-diagnostics-consumers__table .data-table__row:hover .data-table__td:first-child{background-color:var(--ydb-data-table-color-hover)!important}.ydb-diagnostics-consumers__table .data-table__head-row:first-child .data-table__th:nth-child(0),.ydb-diagnostics-consumers__table .data-table__td:nth-child(0){border-right:unset;box-shadow:unset}.ydb-diagnostics-consumers__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-consumers__table .data-table__td:first-child{box-shadow:unset}.ydb-json-viewer{--data-table-row-height:20px;--toolbar-background-color:var(--g-color-base-background);width:max-content}.ydb-json-viewer__toolbar{background-color:var(--toolbar-background-color);left:0;padding-bottom:var(--g-spacing-2);position:sticky;top:0;z-index:2}.ydb-json-viewer__content{font-family:var(--g-font-family-monospace)}.ydb-json-viewer__row{height:1em}.ydb-json-viewer__cell{position:relative}.ydb-json-viewer__cell,.ydb-json-viewer__cell *{white-space:nowrap!important}.ydb-json-viewer__collapsed{margin-left:-3ex;margin-top:-2px;position:absolute}.ydb-json-viewer__match-counter{text-wrap:nowrap;align-content:center;color:var(--g-color-text-secondary)}.ydb-json-viewer__key{color:var(--g-color-text-misc)}.ydb-json-viewer__value_type_string{color:var(--color-unipika-string)}.ydb-json-viewer__value_type_boolean{color:var(--color-unipika-bool)}.ydb-json-viewer__value_type_null{color:var(--color-unipika-null)}.ydb-json-viewer__value_type_int64{color:var(--color-unipika-int)}.ydb-json-viewer__value_type_double{color:var(--color-unipika-float)}.ydb-json-viewer__filter{width:300px}.ydb-json-viewer__filtered_highlighted{background-color:var(--g-color-base-generic-medium)}.ydb-json-viewer__filtered_clickable{color:var(--g-color-text-info);cursor:pointer}.ydb-json-viewer__match-btn{margin-left:-1px}.ydb-json-viewer__full-value{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin:var(--g-spacing-3) 0;max-height:90vh;max-width:90vw;overflow:hidden auto;word-break:break-all}.ydb-json-viewer__extra-tools{margin-left:1ex}.ydb-json-viewer .data-table__head{display:none}.ydb-json-viewer .data-table__td{overflow:visible;padding:0}.ydb-describe__message-container{padding:15px 0}.ydb-describe__result{display:flex;flex:0 0 auto;padding:0 20px 20px 0;position:relative}.ydb-external-data-source-info__location,.ydb-external-table-info__location{max-width:var(--tenant-object-info-max-value-width)}.ydb-syntax-highlighter{height:100%;position:relative;z-index:0}.ydb-syntax-highlighter__sticky-container{background-color:var(--g-color-base-background);left:0;position:sticky;top:52px;top:0;z-index:1}.ydb-syntax-highlighter__copy{opacity:0;pointer-events:all;position:absolute;right:14px;top:13px}.data-table__row:hover .ydb-syntax-highlighter__copy,.ydb-paginated-table__row:hover .ydb-syntax-highlighter__copy,.ydb-syntax-highlighter__copy_visible{opacity:1}.ydb-definition-list{display:flex;flex:1 1 auto;flex-direction:column}.ydb-definition-list__title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-definition-list__properties-list{max-width:calc(100% - 40px)}.ydb-async-replication-paths__title,.ydb-overview-topic-stats__title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-overview-topic-stats .ydb-loader{margin-top:50px}.ydb-overview-topic-stats .info-viewer__row{align-items:flex-start}.ydb-overview-topic-stats .speed-multimeter{margin-top:-5px}.ydb-overview-topic-stats .speed-multimeter__content{justify-content:flex-start}.ydb-overview-topic-stats__info .info-viewer__label-text_multiline{max-width:150px}.ydb-overview-topic-stats__bytes-written{margin-top:7px;padding-left:20px}.ydb-overview-topic-stats__bytes-written .info-viewer__label{min-width:180px}.ydb-diagnostics-table-info__title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-diagnostics-table-info__row{align-items:flex-start;display:flex;flex-wrap:wrap;justify-content:flex-start}.ydb-diagnostics-table-info__col{align-items:flex-start;display:flex;flex-direction:column;justify-content:flex-start}.ydb-diagnostics-table-info__col:not(:last-child){margin-right:50px}.ydb-diagnostics-table-info__info-block{margin-bottom:20px}.ydb-diagnostics-table-info__info-block .info-viewer__items{grid-template-columns:minmax(max-content,280px)}.ydb-metric-chart{border:1px solid var(--g-color-line-generic);border-radius:8px;display:flex;flex-direction:column;padding:16px 16px 8px}.ydb-metric-chart__title{margin-bottom:10px}.ydb-metric-chart__chart{display:flex;height:100%;overflow:hidden;position:relative;width:100%}.ydb-metric-chart__error{left:50%;position:absolute;text-align:center;top:10%;transform:translateX(-50%);z-index:1}.ydb-timeframe-selector{display:flex;gap:2px}.ydb-tenant-dashboard{margin-bottom:var(--diagnostics-section-margin);width:var(--diagnostics-section-table-width)}.ydb-tenant-dashboard__controls{margin-bottom:10px}.ydb-tenant-dashboard__charts{display:flex;flex-flow:row wrap;gap:16px}.issue-tree-item{align-items:center;cursor:pointer;display:flex;height:40px;justify-content:space-between}.issue-tree-item__field{display:flex;overflow:hidden}.issue-tree-item__field_status{display:flex;white-space:nowrap}.issue-tree-item__field_additional{color:var(--g-color-text-link);cursor:pointer;width:max-content}.issue-tree-item__field_additional:hover{color:var(--g-color-text-link-hover)}.issue-tree-item__field_message{flex-shrink:0;overflow:hidden;white-space:normal;width:300px}.issue-tree-item__field-tooltip.issue-tree-item__field-tooltip{max-width:500px;min-width:500px}.issue-tree-item__field-label{color:var(--g-color-text-secondary)}.issue-tree{display:flex}.issue-tree__block{width:100%}.issue-tree__checkbox{margin:5px 0 10px}.issue-tree__info-panel{background:var(--g-color-base-generic);border-radius:4px;height:100%;margin:11px 0;padding:8px 20px;position:sticky}.issue-tree__info-panel .ydb-json-viewer{--toolbar-background-color:var(--g-color-base-simple-hover-solid)}.issue-tree .ydb-tree-view__item{height:40px}.issue-tree .ydb-tree-view .tree-view_arrow{height:40px;width:40px}.issue-tree .ydb-tree-view .ydb-tree-view__item{margin-left:calc(24px*var(--ydb-tree-view-level))!important;padding-left:0!important}.issue-tree .ydb-tree-view .issue-tree__info-panel{margin-left:calc(24px*var(--ydb-tree-view-level))}.healthcheck__details{width:872px}.healthcheck__details-content-wrapper{overflow-x:hidden}.healthcheck__preview{display:flex;flex-direction:column;height:100%}.healthcheck__preview-title{color:var(--g-color-text-link);font-size:var(--g-text-subheader-3-font-size);font-weight:600;line-height:var(--g-text-subheader-3-line-height)}.healthcheck__preview-content{line-height:24px;margin:auto}.healthcheck__preview-status-icon{height:64px;width:64px}.healthcheck__preview-title-wrapper{align-items:center;display:flex;gap:8px;margin-bottom:4px}.healthcheck__preview-issue{align-items:center;display:flex;flex-direction:column;gap:4px;position:relative;top:-8px}.healthcheck__preview-issue_good{color:var(--g-color-text-positive)}.healthcheck__preview-issue_good .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-positive-light)}.healthcheck__preview-issue_degraded{color:var(--g-color-text-info)}.healthcheck__preview-issue_degraded .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-info-light)}.healthcheck__preview-issue_emergency{color:var(--g-color-text-danger)}.healthcheck__preview-issue_emergency .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-danger-light)}.healthcheck__preview-issue_unspecified{color:var(--g-color-text-misc)}.healthcheck__preview-issue_unspecified .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-misc-light)}.healthcheck__preview-issue_maintenance_required{color:var(--g-color-text-warning-heavy)}.healthcheck__preview-issue_maintenance_required .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-warning-light)}.healthcheck__self-check-status-indicator{text-wrap:nowrap;border-radius:4px;display:inline-block;font-size:13px;line-height:24px;padding:0 8px}.healthcheck__icon-warn{color:var(--g-color-text-warning)}.healthcheck__icon-wrapper{display:flex}.ydb-diagnostic-card{background-color:#0000;border:1px solid var(--g-color-line-generic);border-radius:8px;flex-shrink:0;padding:16px 16px 28px}.ydb-diagnostic-card_active{background-color:var(--g-color-base-selection);border-color:var(--g-color-base-info-medium)}.ydb-diagnostic-card_interactive:hover{box-shadow:0 1px 5px var(--g-color-sfx-shadow);cursor:pointer}.ydb-diagnostic-card_size_m{min-width:206px;width:206px}.ydb-diagnostic-card_size_l{min-width:289px;width:289px}.ydb-diagnostic-card_size_s{min-width:134px;width:134px}.ydb-metrics-card{min-height:252px}.ydb-metrics-card__header{align-items:center;display:flex;gap:8px;justify-content:space-between;margin-bottom:10px}.ydb-metrics-card__label{color:var(--g-color-text-link);font-size:var(--g-text-subheader-3-font-size);font-weight:600;line-height:var(--g-text-subheader-3-line-height)}.ydb-metrics-card__content{color:var(--g-color-text-secondary);display:flex;flex-direction:column;gap:10px}.ydb-metrics-card__metric-title{height:var(--g-text-body-2-line-height)}.ydb-metrics-card_active .ydb-metrics-card__content{color:var(--g-color-text-complementary)}.metrics-cards{display:flex;gap:16px;margin-bottom:32px}.metrics-cards__tab{color:inherit;text-decoration:none}.confirmation-dialog__caption,.confirmation-dialog__message{white-space:pre-wrap}.ydb-save-query__dialog-row{align-items:flex-start;display:flex}.ydb-save-query__dialog-row+.ydb-save-query__dialog-row{margin-top:var(--g-text-body-1-line-height)}.ydb-save-query__field-title{font-weight:500;line-height:28px;margin-right:12px;white-space:nowrap}.ydb-save-query__field-title.required:after{color:var(--g-color-text-danger);content:"*"}.ydb-save-query__control-wrapper{display:flex;flex-grow:1;min-height:48px}.kv-truncated-query{max-width:100%;vertical-align:top;white-space:pre;word-break:break-word}.kv-truncated-query__message{white-space:pre-wrap}.kv-truncated-query__message_color_secondary{color:var(--g-color-text-secondary)}.kv-top-queries{display:flex;flex-direction:column;height:100%}.kv-top-queries .data-table__box .data-table__table-wrapper{padding-bottom:20px}.kv-top-queries .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.kv-top-queries__search{width:238px}.kv-top-queries__row{cursor:pointer}.kv-top-queries__row_active{background-color:var(--g-color-base-selection)}.kv-top-queries__row_active:hover{background:var(--g-color-base-selection-hover)!important}.kv-top-queries__query{overflow:hidden;text-overflow:ellipsis;vertical-align:top;white-space:pre-wrap;word-break:break-word}.kv-top-queries__user-sid{max-width:200px;overflow:hidden;text-overflow:ellipsis}.kv-top-queries__drawer{margin-top:calc(var(--g-spacing-4)*-1)}.kv-top-queries__empty-state-icon{color:var(--g-color-text-primary)}.kv-top-queries__not-found-container{height:100%;padding:var(--g-spacing-5) 0}.kv-top-queries__not-found-description{margin-top:var(--g-spacing-2)}.kv-top-queries__not-found-close{margin-top:var(--g-spacing-5)}.tenant-overview{height:100%;overflow:auto;padding-bottom:20px}.tenant-overview__loader{display:flex;justify-content:center}.tenant-overview__tenant-name-wrapper{align-items:center;display:flex;overflow:hidden}.tenant-overview__top{line-height:24px;margin-bottom:10px}.tenant-overview__top-label{font-weight:600;gap:10px;line-height:24px;margin-bottom:var(--diagnostics-section-title-margin)}.tenant-overview__info{left:0;position:sticky;width:max-content}.tenant-overview__title{font-size:var(--g-text-body-2-font-size);font-weight:700;line-height:var(--g-text-body-2-line-height);margin-bottom:10px}.tenant-overview__table:not(:last-child){margin-bottom:var(--diagnostics-section-margin)}.tenant-overview__top-queries-row{cursor:pointer}.tenant-overview__storage-info{margin-bottom:36px}.tenant-overview__memory-info{margin-bottom:36px;width:300px}.kv-detailed-overview{display:flex;flex-direction:column;gap:20px;height:100%;width:100%}.kv-detailed-overview__section{display:flex;flex-basis:calc(50% - 10px);flex-direction:column;flex-grow:1;flex-shrink:0;min-width:300px}.kv-detailed-overview__modal .g-modal__content{position:relative}.kv-detailed-overview__close-modal-button{position:absolute;right:13px;top:23px}.ydb-hot-keys__primary-key-column{align-items:center;display:flex;gap:5px}.ydb-hot-keys__help-card{left:0;margin-bottom:20px;padding:20px 40px 20px 20px;position:sticky}.ydb-hot-keys__help-card__close-button{position:absolute;right:5px;top:5px}.node-network{border:1px solid #0000;border-radius:4px;box-sizing:border-box;color:var(--g-color-text-complementary);cursor:pointer;display:inline-block;font-size:12px;height:14px;line-height:14px;margin-bottom:5px;margin-right:5px;padding:0 5px;text-align:center;text-transform:uppercase;width:14px}.node-network_id{height:14px;width:42px}.node-network_blur{opacity:.25}.node-network_grey{background:var(--ydb-color-status-grey)}.node-network_black{background-color:var(--ydb-color-status-black);color:var(--g-color-text-light-primary)}.node-network_green{background-color:var(--ydb-color-status-green)}.node-network_yellow{background-color:var(--ydb-color-status-yellow)}.node-network_red{background-color:var(--ydb-color-status-red)}.node-network:hover{border:1px solid var(--g-color-text-primary)}.network{flex-direction:column;font-size:var(--g-text-body-2-font-size);justify-content:space-between;line-height:var(--g-text-body-2-line-height);max-width:1305px}.network,.network__nodes-row{display:flex;flex-grow:1;height:100%;overflow:auto}.network__nodes-row{align-items:flex-start;flex-direction:row}.network__inner{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.network__right{height:100%;padding-left:20px;width:100%}.network__left{border-right:1px solid var(--g-color-base-generic-accent);height:100%}.network__placeholder{align-items:center;display:flex;flex-direction:column;flex-grow:1;height:100%;justify-content:center;width:100%}.network__placeholder-text{margin-top:15px}.network__placeholder-img{color:#0000}.network__nodes{display:flex;flex-wrap:wrap}.network__nodes-container{min-width:325px}.network__nodes-container_right{margin-right:60px}.network__nodes-title{border-bottom:1px solid var(--g-color-base-generic-accent);color:var(--g-color-text-secondary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin:0 0 15px}.network__link{color:var(--g-color-base-brand);text-decoration:none}.network__title{font-size:var(--g-text-body-1-font-size);font-weight:500;line-height:var(--g-text-body-1-line-height);margin:20px 0}.network__checkbox-wrapper{align-items:center;display:flex}.network__checkbox-wrapper label{white-space:nowrap}.network__label{margin-bottom:16px}.network__controls{display:flex;gap:12px;margin:0 16px 16px 0}.network__controls-wrapper{display:flex;flex:1 1 auto;flex-direction:row;flex-direction:column}.network__select{margin:0 15px;max-width:115px}.network__rack-column{align-items:center;background-color:#00000012;border-radius:4px;display:flex;flex-direction:column;margin-bottom:5px;margin-right:5px;padding:2px}.network__rack-column .node-network{margin-right:0}.ydb-multiline-table-header{white-space:normal}.ydb-diagnostics-partitions-columns-header__read-session{white-space:normal;width:80px}.ydb-diagnostics-partitions-columns-header__lags{white-space:nowrap}.ydb-diagnostics-partitions-columns-header__messages{white-space:normal;width:90px}.ydb-diagnostics-partitions-columns-header__messages-popover-content{max-width:200px}.ydb-diagnostics-partitions-columns__lags-header{text-align:center}.ydb-diagnostics-partitions{display:flex;flex-grow:1;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto}.ydb-diagnostics-partitions__consumer-select{width:220px}.ydb-diagnostics-partitions__select-option_empty{color:var(--g-color-text-hint)}.ydb-diagnostics-partitions__search{width:238px}.ydb-diagnostics-partitions__search_partition{width:100px}.ydb-diagnostics-partitions__search_general{width:280px}.ydb-diagnostics-partitions__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-partitions__table .data-table__td:first-child{background-color:var(--g-color-base-background);border-right:1px solid var(--g-color-line-generic);left:0;position:sticky;z-index:2000}.ydb-diagnostics-partitions__table .data-table__row:hover .data-table__td:first-child{background-color:var(--ydb-data-table-color-hover)!important}.ydb-diagnostics-partitions__table .data-table__head-row:first-child .data-table__th:nth-child(0),.ydb-diagnostics-partitions__table .data-table__td:nth-child(0){border-right:unset;box-shadow:unset}.ydb-diagnostics-partitions__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-partitions__table .data-table__td:first-child{box-shadow:unset}.ydb-copy-link-button__icon{pointer-events:none}.ydb-query-details{background-color:var(--g-color-base-background-dark);color:var(--g-color-text-primary);flex:1 1}.ydb-query-details__content{flex:1 1;overflow:auto;padding:var(--g-spacing-5) var(--g-spacing-4) var(--g-spacing-5) var(--g-spacing-4)}.ydb-query-details__query-header{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:flex;justify-content:space-between;padding:var(--g-spacing-2) var(--g-spacing-3)}.ydb-query-details__query-title{font-size:14px;font-weight:500}.ydb-query-details__query-content{background-color:var(--code-background-color);border-radius:4px;display:flex;flex:1 1;flex-direction:column;margin-top:var(--g-spacing-5);position:relative}.date-range__range-input_s{width:130px}.date-range__range-input_m{width:300px}.date-range__range-input_l{width:350px}.date-range__range-input input{cursor:pointer}.top-shards__hint{left:0;position:sticky;width:max-content}.ydb-fullscreen{flex-grow:1;overflow:hidden}.ydb-fullscreen_fullscreen{background-color:var(--g-color-base-background);inset:0;position:absolute;z-index:10}.ydb-fullscreen__close-button{display:none;position:fixed;right:20px;top:8px;z-index:11}.ydb-fullscreen_fullscreen .ydb-fullscreen__close-button{display:block}.ydb-fullscreen__content{display:flex;height:100%;overflow:auto;width:100%}.link,.ydb-diagnostics-topic-data-columns__offset_link{color:var(--g-color-text-link);text-decoration:none}.link:hover,.ydb-diagnostics-topic-data-columns__offset_link:hover{color:var(--g-color-text-link-hover)}.ydb-diagnostics-topic-data-columns__offset{align-items:center;display:inline-flex;gap:var(--g-spacing-1);height:100%;width:100%}.ydb-diagnostics-topic-data-columns__offset_removed{cursor:not-allowed;text-decoration:line-through}.ydb-diagnostics-topic-data-columns__message_invalid,.ydb-diagnostics-topic-data-columns__truncated{font-style:italic}.ydb-diagnostics-topic-data-columns__help{white-space:pre-wrap}.ydb-diagnostics-topic-data-columns__help-popover{display:flex}.ydb-diagnostics-message-details{font-size:var(--g-text-body-2-font-size);height:100%;line-height:var(--g-text-body-2-line-height);padding:var(--g-spacing-4);width:100%}.ydb-diagnostics-message-details__list{--g-definition-list-item-gap:var(--g-spacing-1)}.ydb-diagnostics-message-details__details{padding-right:var(--g-spacing-4)}.ydb-diagnostics-message-details__section{background-color:var(--code-background-color);border-radius:var(--g-border-radius-m) var(--g-border-radius-m) var(--g-border-radius-xs) var(--g-border-radius-xs)}.ydb-diagnostics-message-details__section-title-wrapper{border-bottom:1px solid var(--g-color-line-generic);line-height:28px;padding:var(--g-spacing-half) var(--g-spacing-2) var(--g-spacing-half) var(--g-spacing-3)}.ydb-diagnostics-message-details__section-content{padding:var(--g-spacing-2) 0 0 0}.ydb-diagnostics-message-details__section-scroll-container{max-height:60vh;overflow:auto;padding:0 var(--g-spacing-2) var(--g-spacing-3) var(--g-spacing-3);scrollbar-color:var(--g-color-line-generic) #0000;scrollbar-width:thin}.ydb-diagnostics-message-details__message-meta{padding-right:var(--g-spacing-9)}.ydb-diagnostics-message-details__json-viewer-toolbar{background-color:var(--code-background-color)}.ydb-diagnostics-message-details__string-message{overflow:hidden;white-space:pre-wrap;word-break:break-all}.ydb-diagnostics-topic-data__partition-select{min-width:150px}.ydb-diagnostics-topic-data__full-value{max-height:80vh;max-width:70vw;word-break:break-all}.ydb-diagnostics-topic-data__date-picker{min-width:265px}.ydb-diagnostics-topic-data__offset-input{width:max-content}.ydb-diagnostics-topic-data__row_active{background-color:var(--g-color-base-selection)}.ydb-diagnostics-topic-data__row_active:hover{background:var(--g-color-base-selection-hover)!important}.ydb-diagnostics-topic-data__row_removed{color:var(--g-color-text-secondary)}.ydb-diagnostics-topic-data__scroll-button{margin-right:var(--g-spacing-half)}.kv-tenant-diagnostics{--diagnostics-margin-top:var(--g-spacing-4);display:flex;flex-direction:column;height:100%;overflow:hidden}.kv-tenant-diagnostics__header-wrapper{background-color:var(--g-color-base-background);padding:0 var(--g-spacing-5)}.kv-tenant-diagnostics__tabs{--g-tabs-border-width:0;align-items:center;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic);display:flex;justify-content:space-between}.kv-tenant-diagnostics__tabs .g-tabs_direction_horizontal{box-shadow:unset}.kv-tenant-diagnostics__tab{margin-right:40px;text-decoration:none}.kv-tenant-diagnostics__tab:first-letter{text-transform:uppercase}.kv-tenant-diagnostics__page-wrapper{flex-grow:1;height:calc(100% - var(--diagnostics-margin-top));margin-top:var(--diagnostics-margin-top);overflow:auto;padding:0 var(--g-spacing-5);width:100%}.kv-tenant-diagnostics__page-wrapper .ydb-table-with-controls-layout__controls{height:46px;padding-top:0}.kv-tenant-diagnostics__page-wrapper .ydb-table-with-controls-layout .data-table__sticky_moving,.kv-tenant-diagnostics__page-wrapper .ydb-table-with-controls-layout .ydb-paginated-table__head{top:46px!important}.ydb-queries-history{display:flex;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto;padding:0 20px}.ydb-queries-history .ydb-table-with-controls-layout__controls{height:46px;padding-top:0}.ydb-queries-history.ydb-table-with-controls-layout .data-table__sticky_moving{top:46px!important}.ydb-queries-history__search{width:238px}.ydb-queries-history__table-row{cursor:pointer}.ydb-queries-history__query{flex-grow:1;overflow:hidden;text-overflow:ellipsis;white-space:pre}.kv-pane-visibility-button_hidden{display:none}.kv-pane-visibility-button_bottom{transform:rotate(180deg)}.kv-pane-visibility-button_bottom.rotate{transform:rotate(0)}.kv-pane-visibility-button_left{transform:rotate(-90deg)}.kv-pane-visibility-button_left.rotate{transform:rotate(90deg)}.kv-pane-visibility-button_top.rotate{transform:rotate(180deg)}.ydb-query-result-table__cell{cursor:pointer;display:inline-block;max-width:600px;overflow:hidden;text-overflow:ellipsis;vertical-align:middle;white-space:nowrap;width:100%}.ydb-query-result-table__message{padding:15px 10px}.ydb-query-result-table__table-wrapper{height:0}.ydb-preview{display:flex;flex:1 1 auto;flex-direction:column;height:100%}.ydb-preview .data-table__box .data-table__table-wrapper{padding-bottom:20px}.ydb-preview .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.ydb-preview__header{background-color:var(--g-color-base-background);border-bottom:1px solid var(--g-color-line-generic);flex-shrink:0;height:53px;padding:0 var(--g-spacing-6);position:sticky;top:0}.ydb-preview__table-name{color:var(--g-color-text-complementary);margin-left:var(--g-spacing-1)}.ydb-preview__controls-left{display:flex;gap:var(--g-spacing-1)}.ydb-preview__message-container{padding:var(--g-spacing-3) 0}.ydb-preview__result{overflow:auto;padding-left:var(--g-spacing-5);width:100%}.ydb-preview__partition-info{height:36px;padding-left:var(--g-spacing-1)}.ydb-query-settings-description__message{display:flex;flex-wrap:wrap;white-space:pre}.ydb-query-editor-button__explain-button,.ydb-query-editor-button__run-button,.ydb-query-editor-button__stop-button{width:92px}.ydb-query-editor-button__stop-button_error{animation:errorAnimation .5s linear}@keyframes errorAnimation{41%,8%{transform:translateX(-2px)}25%,58%{transform:translateX(2px)}75%{transform:translateX(-1px)}92%{transform:translateX(1px)}0%,to{transform:translateX(0)}}.ydb-query-editor-controls{align-items:center;display:flex;flex:0 0 60px;gap:24px;justify-content:space-between;min-height:60px}.ydb-query-editor-controls__left,.ydb-query-editor-controls__right{display:flex;gap:12px}.ydb-query-editor-controls__mode-selector__button{margin-left:2px;width:241px}.ydb-query-editor-controls__mode-selector__button-content{align-items:center;display:flex;justify-content:space-between;width:215px}.ydb-query-editor-controls__mode-selector__popup{width:241px}.ydb-query-editor-controls__item-with-popover{align-items:center;display:flex;height:24px;line-height:normal}.ydb-query-editor-controls__popover{max-width:420px;white-space:pre-wrap}.kv-query-execution-status{align-items:center;display:flex;gap:4px}.ydb-query-settings-banner,.ydb-query-stopped-banner{margin-left:var(--g-spacing-4);margin-right:var(--g-spacing-4);margin-top:var(--g-spacing-4)}.ydb-query-ast{height:100%;overflow:hidden;white-space:pre-wrap;width:100%}.ydb-query-result-stub-message{padding:15px 20px}.ydb-query-explain-graph__canvas-container{height:100%;overflow-y:auto;width:100%}.query-info-dropdown__menu-item{align-items:start}.query-info-dropdown__menu-item-content{display:flex;flex-direction:column;padding:var(--g-spacing-1) 0}.query-info-dropdown__icon{margin-right:var(--g-spacing-2);margin-top:var(--g-spacing-2)}.ydb-query-json-viewer{height:100%;padding:15px 0;width:100%}.ydb-query-json-viewer__tree{height:100%;overflow-y:auto;padding:0 10px;width:100%}.ydb-query-result-error__message{padding-left:var(--g-spacing-4);padding-top:var(--g-spacing-4)}.ydb-query-result-sets-viewer__tabs{margin-bottom:var(--g-spacing-1);padding-left:var(--g-spacing-4);padding-top:var(--g-spacing-1)}.ydb-query-result-sets-viewer__title{padding-bottom:var(--g-spacing-4);padding-left:var(--g-spacing-4);padding-top:var(--g-spacing-4)}.ydb-query-result-sets-viewer__result-wrapper{display:flex;flex-direction:column;width:100%}.ydb-query-result-sets-viewer__result{display:flex;flex-direction:column;flex-grow:1;overflow:auto;padding-left:10px}.ydb-query-result-sets-viewer__result .data-table__box .data-table__table-wrapper{padding-bottom:20px}.ydb-query-result-sets-viewer__result .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.ydb-query-result-sets-viewer__result .data-table__table-wrapper{padding-bottom:0}.ydb-table{--ydb-table-cell-height:40px}.ydb-table__table-header-content{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:inline-flex;height:100%;padding:var(--g-spacing-1) var(--g-spacing-2);width:100%}.ydb-table__table{border-collapse:collapse;border-spacing:0;table-layout:fixed}.ydb-table__table tr:hover{background-color:var(--g-color-base-simple-hover)!important}.ydb-table__table tr:nth-of-type(odd){background-color:var(--g-color-base-generic-ultralight)}.ydb-table__table_width_max{width:100%}.ydb-table__table-header-cell{background-color:var(--g-color-base-background);font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-subheader-2-line-height);padding:0;text-align:left;vertical-align:middle}:is(.ydb-table__table-header-cell_align_right) .ydb-table__table-header-content{justify-content:flex-end;text-align:right}.ydb-table__table-cell{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-body-2-line-height);padding:0}.ydb-table__table-cell_align_right{text-align:right!important}.ydb-table__table-cell_vertical-align_top{vertical-align:top!important}.ydb-query-simplified-plan{height:100%;overflow:auto;padding:0 15px 15px;width:100%}.ydb-query-simplified-plan__name{align-items:center;display:flex;gap:var(--g-spacing-1);max-width:100%}.ydb-query-simplified-plan__metrics-cell{padding:var(--g-spacing-1) var(--g-spacing-2)}.ydb-query-simplified-plan__operation-params{color:var(--g-color-text-secondary)}.ydb-query-simplified-plan__operation-name{font-weight:500;height:100%;max-width:100%;position:relative}.ydb-query-simplified-plan__divider{bottom:0;box-shadow:1px 0 0 0 var(--g-color-line-generic) inset;height:100%;position:absolute;width:12px}.ydb-query-simplified-plan__divider_last{border-radius:0 0 0 1px;bottom:unset;box-shadow:1px -1px 0 0 var(--g-color-line-generic) inset;height:14px;top:0;width:12px}.ydb-query-simplified-plan__divider_horizontal{bottom:unset;box-shadow:0 -1px 0 0 var(--g-color-line-generic) inset;height:14px;top:0;width:12px}.ydb-query-simplified-plan__divider_first{height:calc(100% - 30px)}.ydb-query-simplified-plan__operation-content{height:100%;max-width:100%;padding:var(--g-spacing-1) 0;word-break:break-word}.ydb-query-simplified-plan__operation-name-content{display:flex;flex-grow:1}.ydb-query-result__controls{align-items:center;background-color:var(--g-color-base-background);border-bottom:1px solid var(--g-color-line-generic);display:flex;height:53px;justify-content:space-between;padding:var(--g-spacing-3) var(--g-spacing-4);position:sticky;top:0;z-index:2}.ydb-query-result__controls-left{align-items:center;display:flex;gap:12px;height:100%}.ydb-query-result__controls-right{display:flex;gap:4px}.ydb-query-result__elapsed-label{margin-left:var(--g-spacing-3)}.ydb-query-settings-select__selector{width:100%}.ydb-query-settings-select__popup{max-width:320px}.ydb-query-settings-select__item-description{color:var(--g-color-text-secondary);white-space:pre-wrap}.ydb-query-settings-select__item{padding:var(--g-spacing-1) 0}.ydb-timeout-label__switch{align-items:center;height:var(--g-text-header-2-line-height);margin-right:var(--g-spacing-1)}.ydb-timeout-label__label-title,.ydb-timeout-label__switch-title{align-items:center;flex:4 1;font-weight:500;margin-right:var(--g-spacing-3);white-space:nowrap}.ydb-timeout-label__label-title{line-height:var(--g-text-header-2-line-height)}.ydb-query-settings-timeout__control-wrapper{align-items:center;display:flex;flex:6 1}.ydb-query-settings-timeout__input{width:50%}.ydb-query-settings-timeout__postfix{color:var(--g-color-text-secondary);margin-right:var(--g-spacing-2)}.ydb-query-settings-dialog__dialog-row+.ydb-query-settings-dialog__dialog-row{margin-top:var(--g-text-body-1-line-height)}.ydb-query-settings-dialog__field-title{flex:4 1;font-weight:500;line-height:var(--g-text-header-2-line-height);margin-right:var(--g-spacing-3);white-space:nowrap}.ydb-query-settings-dialog .g-dialog-footer__bts-wrapper{width:100%}.ydb-query-settings-dialog__dialog-body{padding-top:var(--g-spacing-6)}.ydb-query-settings-dialog__control-wrapper{display:flex;flex:6 1}.ydb-query-settings-dialog__limit-rows{margin-right:var(--g-spacing-2);width:50%}.ydb-query-settings-dialog__postfix{color:var(--g-color-text-secondary);margin-right:var(--g-spacing-2)}.ydb-query-settings-dialog__buttons-container{display:flex;justify-content:space-between;width:100%}.ydb-query-settings-dialog__main-buttons{display:flex;gap:10px}.query-editor{display:flex;flex:1 1 auto;flex-direction:column;height:100%;position:relative}.query-editor .data-table__box .data-table__table-wrapper{padding-bottom:20px}.query-editor .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.query-editor .data-table__box .data-table__table-wrapper{padding-bottom:0}.query-editor__monaco{border:1px solid var(--g-color-line-generic);display:flex;height:100%;position:relative;width:100%}.query-editor__monaco-wrapper{height:calc(100% - 49px);min-height:0;width:100%}.query-editor__pane-wrapper{background-color:var(--g-color-base-background);display:flex;flex-direction:column;z-index:2}.query-editor__pane-wrapper_top{border-bottom:1px solid var(--g-color-line-generic);padding:0 16px}.ydb-saved-queries{display:flex;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto;padding:0 20px}.ydb-saved-queries .ydb-table-with-controls-layout__controls{height:46px;padding-top:0}.ydb-saved-queries.ydb-table-with-controls-layout .data-table__sticky_moving{top:46px!important}.ydb-saved-queries__search{width:238px}.ydb-saved-queries__row{cursor:pointer}.ydb-saved-queries__row :hover .ydb-saved-queries__controls{display:flex}.ydb-saved-queries__query-name{overflow:hidden;text-overflow:ellipsis;white-space:pre-wrap}.ydb-saved-queries__query{align-items:center;display:flex;flex-direction:row;justify-content:space-between}.ydb-saved-queries__query-body{flex-grow:1;max-width:100%;overflow:hidden;text-overflow:ellipsis;white-space:pre}.ydb-saved-queries__controls{display:none}.ydb-saved-queries__dialog-query-name{font-weight:500}.ydb-query{display:flex;flex:1 1 auto;flex-direction:column;max-height:calc(100% - 56px)}.ydb-query__tabs{padding:0 20px 16px}.ydb-query__content{height:100%;overflow:hidden}.ydb-tenant-navigation{padding:12px 16px 8px}.ydb-tenant-navigation__item{align-items:center;display:flex;gap:5px}.ydb-tenant-navigation__icon{flex-shrink:0}.ydb-tenant-navigation__text{overflow:hidden;text-overflow:ellipsis}.object-general{display:flex;flex-direction:column;flex-grow:1;height:100%;max-height:100%;width:100%}.object-general__loader{display:flex}.ydb-acl{width:100%}.ydb-acl__result{padding-bottom:var(--g-spacing-4);padding-left:var(--g-spacing-2)}.ydb-acl__result_no-title{margin-top:var(--g-spacing-3)}.ydb-acl__definition-content{align-items:flex-end;display:flex;flex-direction:column}.ydb-acl__list-title{font-weight:600;margin:var(--g-spacing-3) 0 var(--g-spacing-5)}.ydb-acl__group-label,.ydb-acl__list-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-2-line-height)}.ydb-schema-create-directory-dialog__label{display:flex;flex-direction:column;margin-bottom:8px}.ydb-schema-create-directory-dialog__description{color:var(--g-color-text-secondary)}.ydb-schema-create-directory-dialog__input-wrapper{min-height:48px}.ydb-object-summary{height:100%;max-height:100%;overflow:hidden;width:100%}.ydb-object-summary,.ydb-object-summary__overview-wrapper{display:flex;flex-direction:column;flex-grow:1;position:relative}.ydb-object-summary__overview-wrapper{overflow:auto;padding:0 12px 16px}.ydb-object-summary_hidden{visibility:hidden}.ydb-object-summary__actions{background-color:var(--g-color-base-background);position:absolute;right:5px;top:19px}.ydb-object-summary__button_hidden{display:none}.ydb-object-summary__tree-wrapper{display:flex;flex-direction:column}.ydb-object-summary__tree{flex:1 1 auto;height:100%;overflow-y:scroll;padding:0 12px 12px 16px}.ydb-object-summary__tree-header{padding:23px 12px 17px 20px}.ydb-object-summary__sticky-top{background-color:var(--g-color-base-background);left:0;position:sticky;top:0;z-index:5}.ydb-object-summary__tabs{padding:8px 12px 16px}.ydb-object-summary__tabs-inner{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic)}.ydb-object-summary__tab{text-decoration:none}.ydb-object-summary__info{display:flex;flex-direction:column;overflow:hidden}.ydb-object-summary__info-controls{display:flex;gap:4px}.ydb-object-summary__info-action-button{background-color:var(--g-color-base-background)}.ydb-object-summary__info-action-button_hidden{display:none}.ydb-object-summary__rotated90{transform:rotate(-90deg)}.ydb-object-summary__rotated180{transform:rotate(180deg)}.ydb-object-summary__rotated270{transform:rotate(90deg)}.ydb-object-summary__info-header{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:flex;justify-content:space-between;padding:12px 12px 10px}.ydb-object-summary__info-title{align-items:center;display:flex;font-weight:600;overflow:hidden}.ydb-object-summary__path-name{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-object-summary__entity-type{background-color:var(--g-color-base-generic);border-radius:3px;display:inline-block;font-weight:400;margin-right:5px;padding:3px 8px;text-transform:lowercase}.ydb-object-summary__entity-type_error{background-color:#0000;padding:3px 0}.ydb-object-summary__overview-title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-object-summary__overview-item-content{text-align:end;white-space:nowrap}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.tenant-page{display:flex;flex:1 1 auto;flex-direction:column;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);overflow:hidden}.tenant-page__main{flex-grow:1} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/35566.545f7f9d.chunk.css b/ydb/core/viewer/monitoring/static/css/35566.545f7f9d.chunk.css new file mode 100644 index 000000000000..876cff458bbf --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/35566.545f7f9d.chunk.css @@ -0,0 +1,9 @@ +@charset "UTF-8";.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.gc-help-popover__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.gc-help-popover__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.gc-definition-list__list{margin:0}.gc-definition-list__group-title{margin-block-end:var(--g-spacing-3)}.gc-definition-list__group-title:not(:first-of-type){margin-block-start:var(--g-spacing-5)}.gc-definition-list__item{align-items:baseline;display:flex;gap:var(--g-spacing-1)}.gc-definition-list__item+.gc-definition-list__item{margin-block-start:var(--g-spacing-4)}.gc-definition-list__item_grouped+.gc-definition-list__item_grouped{margin-block-start:var(--g-spacing-3)}.gc-definition-list_margin:not(:first-of-type){margin-block-start:var(--g-spacing-5)}.gc-definition-list__term-container{align-items:baseline;display:flex;flex:0 0 auto;max-width:300px;overflow:hidden;position:relative;width:300px}.gc-definition-list__term-wrapper{color:var(--g-color-text-secondary);flex:0 1 auto;overflow:hidden;position:relative;text-overflow:ellipsis;white-space:nowrap}.gc-definition-list__term-container_multiline .gc-definition-list__term-wrapper{white-space:unset}.gc-definition-list__term-container_multiline .gc-definition-list__item-note-tooltip{position:absolute}.gc-definition-list__dots{border-block-end:1px dotted var(--g-color-line-generic-active);box-sizing:border-box;flex:1 0 auto;margin:0 2px;min-width:40px}.gc-definition-list__dots_with-note{margin-inline-start:15px;min-width:25px}.gc-definition-list__definition{flex:0 1 auto;margin:0}.gc-definition-list_responsive .gc-definition-list__term-container{flex:1 0 auto}.gc-definition-list__copy-container{align-items:center;display:inline-flex;margin-inline-end:calc(var(--g-spacing-7)*-1);padding-inline-end:var(--g-spacing-7);position:relative}.gc-definition-list__copy-container:hover .gc-definition-list__copy-button{opacity:1}.gc-definition-list__copy-container_icon-inside{margin-inline-end:unset;padding-inline-end:unset}.gc-definition-list__copy-container_icon-inside .gc-definition-list__copy-button{inset-block-start:0}.gc-definition-list__copy-button{display:inline-block;inset-inline-end:0;margin-inline-start:10px;opacity:0;position:absolute}.gc-definition-list__copy-button:focus-visible{opacity:1}.gc-definition-list_vertical .gc-definition-list__term-container{flex:1 0 auto}.gc-definition-list_vertical .gc-definition-list__item{flex-direction:column;gap:var(--g-spacing-half)}.gc-definition-list_vertical .gc-definition-list__item+.gc-definition-list__item{margin-block-start:var(--g-spacing-3)}.gc-definition-list_vertical .gc-definition-list__group-title:not(:first-of-type),.gc-definition-list_vertical .gc-definition-list_margin:not(:first-of-type){margin-block-start:var(--g-spacing-8)}.chartkit-loader{align-items:center;display:flex;justify-content:center}.chartkit,.chartkit-loader{height:100%;width:100%}.chartkit_mobile .chartkit-scrollable-node{max-height:3000px}.chartkit-theme_common{--highcarts-navigator-border:var(--g-color-line-generic);--highcarts-navigator-track:var(--g-color-base-generic);--highcarts-navigator-body:var(--g-color-scroll-handle);--highcharts-series-border:var(--g-color-base-background);--highcharts-grid-line:var(--g-color-line-generic);--highcharts-axis-line:var(--g-color-line-generic);--highcharts-tick:var(--g-color-line-generic);--highcharts-title:var(--g-color-text-primary);--highcharts-axis-labels:var(--g-color-text-secondary);--highcharts-data-labels:var(--g-color-text-secondary);--highcharts-plot-line-label:var(--g-color-text-secondary);--highcharts-legend-item:var(--g-color-text-secondary);--highcharts-legend-item-hover:var(--g-color-text-primary);--highcharts-legend-item-hidden:var(--g-color-text-hint);--highcharts-floating-bg:var(--g-color-infographics-tooltip-bg);--highcharts-tooltip-text:var(--g-color-text-primary);--highcharts-tooltip-bg:var(--highcharts-floating-bg);--highcharts-tooltip-alternate-bg:var(--g-color-base-generic);--highcharts-tooltip-text-complementary:var(--g-color-text-secondary);--highcharts-holiday-band:var(--g-color-base-generic)}.ydb-tree-view{--ydb-tree-view-level:0;font-size:13px;line-height:18px}.ydb-tree-view,.ydb-tree-view *{box-sizing:border-box}.ydb-tree-view__item{align-items:center;border-bottom:1px solid var(--g-color-line-generic-solid);cursor:pointer;display:flex;height:24px;padding-left:calc(24px*var(--ydb-tree-view-level));padding-right:3px}.ydb-tree-view__item:hover{background-color:var(--g-color-base-simple-hover)}.ydb-tree-view__item:hover .ydb-tree-view__actions{display:flex}.ydb-tree-view__item_active{background-color:var(--g-color-base-selection);font-weight:700}.ydb-tree-view__item_active:hover{background-color:var(--g-color-base-selection-hover)}.ydb-tree-view__content{align-items:center;display:flex;flex-grow:1;overflow:hidden}.ydb-tree-view__icon{align-items:center;color:var(--g-color-text-hint);display:flex;flex-shrink:0;height:24px;justify-content:center;width:24px}.ydb-tree-view__icon svg{display:block}.ydb-tree-view__text{flex-grow:1;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-tree-view__actions{align-items:center;display:none;margin-left:6px}.ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%;border:none;cursor:pointer;flex-shrink:0;height:24px;padding:0;width:24px}.g-root_theme_dark .ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%}.ydb-tree-view__arrow:focus-visible{outline:2px solid var(--g-color-line-focus)}.ydb-tree-view__arrow:not(.ydb-tree-view__arrow_collapsed){transform:rotate(90deg)}.ydb-tree-view__arrow_hidden{visibility:hidden}.ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:24px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:48px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:72px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:96px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:120px}.g-card{--_--background-color:#0000;--_--border-color:#0000;--_--border-width:0;--_--box-shadow:none;background-color:var(--g-card-background-color,var(--_--background-color));border:var(--g-card-border-width,var(--_--border-width)) solid var(--g-card-border-color,var(--_--border-color));border-radius:var(--g-card-border-radius,var(--_--border-radius));box-shadow:var(--g-card-box-shadow,var(--_--box-shadow));box-sizing:border-box;outline:none}.g-card_theme_normal{--_--border-color:var(--g-color-line-generic);--_--background-color:var(--g-color-base-generic)}.g-card_theme_info{--_--border-color:var(--g-color-line-info);--_--background-color:var(--g-color-base-info-light)}.g-card_theme_success{--_--border-color:var(--g-color-line-positive);--_--background-color:var(--g-color-base-positive-light)}.g-card_theme_warning{--_--border-color:var(--g-color-line-warning);--_--background-color:var(--g-color-base-warning-light)}.g-card_theme_danger{--_--border-color:var(--g-color-line-danger);--_--background-color:var(--g-color-base-danger-light)}.g-card_theme_utility{--_--border-color:var(--g-color-line-utility);--_--background-color:var(--g-color-base-utility-light)}.g-card_view_clear,.g-card_view_outlined{--_--background-color:#0000}.g-card_view_outlined{--_--border-width:1px}.g-card_type_action{--_--background-color:var(--g-color-base-float);--_--box-shadow:0px 1px 5px var(--g-color-sfx-shadow)}.g-card_type_action:after{border-radius:var(--g-card-border-radius,var(--_--border-radius));inset:0;pointer-events:none;position:absolute}.g-card_type_action.g-card_clickable{cursor:pointer;position:relative}.g-card_type_action.g-card_clickable:hover{--_--box-shadow:0px 3px 10px var(--g-color-sfx-shadow)}.g-card_type_action.g-card_clickable:focus-visible:after{content:"";outline:2px solid var(--g-color-line-focus)}.g-card_type_selection{--_--border-width:1px;--_--border-color:var(--g-color-line-generic);position:relative}.g-card_type_selection:before{inset:-1px}.g-card_type_selection:after,.g-card_type_selection:before{border-radius:var(--g-card-border-radius,var(--_--border-radius));pointer-events:none;position:absolute}.g-card_type_selection:after{inset:0}.g-card_type_selection.g-card_clickable{cursor:pointer}.g-card_type_selection.g-card_clickable:hover{--_--border-color:#0000}.g-card_type_selection.g-card_clickable:hover:not(.g-card_selected):before{border:2px solid var(--g-color-line-brand);content:"";opacity:.5}.g-card_type_selection.g-card_clickable:hover:focus-visible:before{border-color:#0000}.g-card_type_selection.g-card_clickable:focus-visible:after{content:"";outline:2px solid var(--g-color-line-focus)}.g-card_type_selection.g-card_selected:not(.g-card_disabled){--_--border-color:#0000}.g-card_type_selection.g-card_selected:not(.g-card_disabled):before{border:2px solid var(--g-color-line-brand);content:""}.g-card_type_selection.g-card_view_clear{--_--border-color:#0000}.g-card_type_container.g-card_view_raised{--_--background-color:var(--g-color-base-float)}.g-card_type_container.g-card_view_raised.g-card_size_m{--_--box-shadow:0px 1px 5px var(--g-color-sfx-shadow)}.g-card_type_container.g-card_view_raised.g-card_size_l{--_--box-shadow:0px 1px 6px var(--g-color-sfx-shadow-light),1px 3px 13px var(--g-color-sfx-shadow-light)}.g-card_size_m{--_--border-radius:8px}.g-card_size_l{--_--border-radius:16px}.g-date-relative-range-date-picker-control__input{caret-color:#0000}.g-date-relative-range-date-picker-control__input_mobile{pointer-events:none}.g-date-relative-range-date-picker-control__mobile-trigger{--_--g-date-mobile-trigger-clear-width:0px;--_--g-date-mobile-trigger-errors-width:0px;--_--g-date-mobile-trigger-button-width:24px;inset:0;inset-inline-end:calc(var(--g-spacing-2) + var(--_--g-date-mobile-trigger-button-width) + var(--_--g-date-mobile-trigger-clear-width) + var(--_--g-date-mobile-trigger-errors-width));opacity:0;position:absolute}.g-date-relative-range-date-picker-control__mobile-trigger_size_s{--_--g-date-mobile-trigger-button-width:20px}.g-date-relative-range-date-picker-control__mobile-trigger_size_l{--_--g-date-mobile-trigger-button-width:28px}.g-date-relative-range-date-picker-control__mobile-trigger_size_xl{--_--g-date-mobile-trigger-button-width:36px}.g-date-relative-range-date-picker-control__mobile-trigger_has-clear{--_--g-date-mobile-trigger-clear-width:calc(var(--_--g-date-mobile-trigger-button-width) + 2px)}.g-date-relative-range-date-picker-control__mobile-trigger_has-errors{--_--g-date-mobile-trigger-errors-width:calc(var(--_--g-date-mobile-trigger-button-width) + 2px)}.g-date-relative-range-date-picker-presets-doc__button{--g-button-background-color-hover:#0000}.g-date-relative-range-date-picker-presets-doc__content{--g-popover-max-width:"none"}.g-date-relative-range-date-picker-presets-doc__table_size_xl{font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-date-relative-range-date-picker-presets-doc__table>table{width:100%}.g-table,.g-table__scroll-container{overflow:auto;position:relative}.g-table__scroll-container{-ms-overflow-style:none;scrollbar-width:none}.g-table__scroll-container::-webkit-scrollbar{display:none}.g-table__horizontal-scroll-bar{margin-block-start:-1px;overflow-x:auto}.g-table__horizontal-scroll-bar-inner{height:1px;position:relative}.g-table__horizontal-scroll-bar-inner:before{background-color:#ffffff03;content:"";height:1px;inset-block-start:0;inset-inline-start:0;position:absolute;width:1px}.g-table__horizontal-scroll-bar_sticky-horizontal-scroll{position:sticky;z-index:3}.g-table__table{border-collapse:initial;border-spacing:0}.g-table__table_width_max{width:100%}.g-table__cell{border-block-end:1px solid var(--g-color-line-generic);box-sizing:initial;line-height:18px;overflow-wrap:break-word;padding:11px var(--g-spacing-2) 10px;text-align:start}.g-table__cell:first-child{padding-inline-start:0}.g-table__cell:last-child{padding-inline-end:0}.g-table__cell:not(.g-table__cell_word-wrap){overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-table__cell_align_center{text-align:center}.g-table__cell_align_end{text-align:end}.g-table .g-table__cell_sticky_end,.g-table .g-table__cell_sticky_start{background:var(--g-color-base-background);position:sticky;z-index:2}.g-table__cell_border_right{border-inline-end:1px solid var(--g-color-line-generic)}.g-table__cell_edge-padding:first-child{padding-inline-start:var(--g-spacing-3)}.g-table__cell_edge-padding:last-child{padding-inline-end:var(--g-spacing-3)}.g-table__row_vertical-align_top{vertical-align:top}.g-table__row_vertical-align_middle{vertical-align:middle}.g-table__row_empty .g-table__cell{text-align:center}.g-table__body .g-table__row:last-child .g-table__cell{border-block-end-color:#0000}.g-table__head .g-table__cell{font-weight:var(--g-text-accent-font-weight)}.g-table__body .g-table__row_interactive:hover{background-color:var(--g-color-base-simple-hover-solid);cursor:pointer}.g-table__body .g-table__row_interactive:hover .g-table__cell_sticky_end,.g-table__body .g-table__row_interactive:hover .g-table__cell_sticky_start{background:var(--g-color-base-simple-hover-solid)}.g-table__body .g-table__row_disabled{opacity:.3}.g-table_with-primary .g-table__body .g-table__cell{color:var(--g-color-text-secondary)}.g-table_with-primary .g-table__body .g-table__cell_primary{color:var(--g-color-text-primary)}.g-table_with-sticky-scroll{overflow:visible}.g-date-relative-range-date-picker-presets{--g-list-item-padding:0 var(--_--g-date-picker-presets-padding,0)}.g-date-relative-range-date-picker-presets__tabs{--g-tabs-border-width:0;align-items:center;box-shadow:inset 0 -1px var(--g-color-line-generic);display:flex;gap:var(--g-spacing-2);padding-inline:var(--_--g-date-picker-presets-padding,0)}.g-date-relative-range-date-picker-presets__list-container{outline:none}.g-date-relative-range-date-picker-presets__doc{margin-inline-start:auto}.g-date-relative-range-date-picker-presets__content{height:128px;overflow:auto}.g-date-relative-range-date-picker-presets_size_l .g-date-relative-range-date-picker-presets__content{height:144px}.g-date-relative-range-date-picker-presets_size_xl .g-date-relative-range-date-picker-presets__content{font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);height:162px;line-height:var(--g-text-body-2-line-height)}.g-date-relative-range-date-picker-zones__control{--g-button-background-color-hover:#0000}.g-date-relative-range-date-picker-dialog__content{--_--popup-content-padding:var(--g-spacing-2);--_--g-date-picker-presets-padding:var(--_--popup-content-padding);padding:var(--_--popup-content-padding)}.g-date-relative-range-date-picker-dialog__content_mobile{--_--popup-content-padding:var(--g-spacing-5)}.g-date-relative-range-date-picker-dialog__content:not(.g-date-relative-range-date-picker-dialog__content_mobile){width:310px}.g-date-relative-range-date-picker-dialog__content_size_xl:not(.g-date-relative-range-date-picker-dialog__content_mobile){width:380px}.g-date-relative-range-date-picker-dialog__pickers{display:flex;flex-direction:column;gap:var(--g-spacing-2)}.g-date-relative-range-date-picker-dialog__pickers .g-text-input__label{width:40px}.g-date-relative-range-date-picker-dialog__content_size_xl .g-date-relative-range-date-picker-dialog__pickers .g-text-input__label{width:50px}.g-date-relative-range-date-picker-dialog__apply{margin-block-start:var(--g-spacing-2)}.g-date-relative-range-date-picker-dialog__zone{border-block-start:1px solid var(--g-color-line-generic);margin-block:var(--g-spacing-2) calc(var(--_--popup-content-padding)*-1)}.g-date-relative-range-date-picker-dialog__presets,.g-date-relative-range-date-picker-dialog__zone{margin-inline:calc(var(--_--popup-content-padding)*-1)}.g-date-mobile-calendar{border:none;box-sizing:border-box;cursor:pointer;height:100%;inset-block-start:0;inset-inline-start:0;margin:0;min-width:100%;opacity:0;padding:0;position:absolute;z-index:1}.g-date-mobile-calendar::-webkit-calendar-picker-indicator{cursor:pointer;height:100%;inset-block-start:0;inset-inline-start:0;margin:0;min-width:100%;padding:0;position:absolute}.g-date-stub-button{display:inline-block;height:24px;position:relative;width:24px}.g-date-stub-button_size_xs{height:20px;width:20px}.g-date-stub-button_size_m{height:28px;width:28px}.g-date-stub-button_size_l{height:36px;width:36px}.g-date-stub-button__icon{align-items:center;color:var(--g-color-text-secondary);display:flex;inset:0;justify-content:center;position:absolute}.g-date-relative-date-picker{display:inline-flex;outline:none;position:relative}.g-date-relative-date-picker__input_mobile{pointer-events:none}.g-date-relative-date-picker__field{width:100%}.g-date-relative-date-picker__popup-content{outline:none}.g-date-relative-date-picker__time-field{width:100%}.g-date-relative-date-picker__time-field-wrapper{padding:10px}.g-date-calendar{--_--calendar-padding:var(--g-date-calendar-padding,8px);--_--calendar-day-size:var(--g-date-calendar-day-size,28px);--_--calendar-days-gap:var(--g-date-calendar-days-gap,2px);--_--calendar-width:calc(var(--_--calendar-day-size)*7 + var(--_--calendar-days-gap)*6 + var(--_--calendar-padding)*2);--_--calendar-grid-height:calc(var(--_--calendar-day-size)*7 + var(--_--calendar-days-gap)*5 + var(--_--calendar-padding));display:inline-block;width:var(--_--calendar-width)}.g-date-calendar_size_l{--g-date-calendar-day-size:36px}.g-date-calendar_size_xl{--g-date-calendar-day-size:42px;font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-date-calendar__header{display:flex;padding:var(--_--calendar-padding) var(--_--calendar-padding) 0}.g-date-calendar__years-label{color:var(--g-color-text-secondary)}.g-date-calendar__controls{margin-inline-start:auto}.g-date-calendar__control-icon{transform:scaleX(var(--g-flow-direction))}.g-date-calendar__grid{height:var(--_--calendar-grid-height);overflow:hidden;position:relative;-webkit-user-select:none;user-select:none;width:100%}.g-date-calendar__content{box-sizing:border-box;display:grid;grid-template-rows:var(--_--calendar-day-size) 1fr;height:100%;inset-block-start:0;inset-inline-start:0;padding:0 var(--_--calendar-padding) var(--_--calendar-padding);position:absolute;width:100%}@keyframes calendar-forward{0%{transform:translateX(0)}to{transform:translateX(100%)}}@keyframes calendar-backward{0%{transform:translateX(0)}to{transform:translateX(-100%)}}@keyframes calendar-zoom-in-showing{0%{opacity:0;transform:scale(2)}to{opacity:1;transform:scale(1)}}@keyframes calendar-zoom-in-hiding{0%{opacity:1;transform:scale(1)}to{opacity:0;transform:scale(0)}}@keyframes calendar-zoom-out-showing{0%{opacity:0;transform:scale(0)}to{opacity:1;transform:scale(1)}}@keyframes calendar-zoom-out-hiding{0%{opacity:1;transform:scale(1)}to{opacity:0;transform:scale(2)}}.g-date-calendar__content_animation_forward{animation:calendar-forward .25s ease forwards;transform:translateX(-100%)}.g-date-calendar__content_animation_forward.g-date-calendar__current-state{inset-inline-start:calc(var(--g-flow-direction)*-100%)}.g-date-calendar__content_animation_backward{animation:calendar-backward .25s ease forwards;transform:translateX(0)}.g-date-calendar__content_animation_backward.g-date-calendar__current-state{inset-inline-start:calc(var(--g-flow-direction)*100%)}.g-date-calendar__content_animation_zoom-in{transform:scale()}.g-date-calendar__content_animation_zoom-in.g-date-calendar__previous-state{animation:calendar-zoom-in-hiding .25s ease forwards}.g-date-calendar__content_animation_zoom-in.g-date-calendar__current-state{animation:calendar-zoom-in-showing .25s ease forwards}.g-date-calendar__content_animation_zoom-out{transform:scale()}.g-date-calendar__content_animation_zoom-out.g-date-calendar__current-state{animation:calendar-zoom-out-showing .25s ease forwards}.g-date-calendar__content_animation_zoom-out.g-date-calendar__previous-state{animation:calendar-zoom-out-hiding .25s ease forwards}@media (update:slow),screen and (prefers-reduced-motion:reduce){.g-date-calendar__content[class]{animation-duration:.001ms}}.g-date-calendar__grid-rowgroup{display:grid;gap:var(--_--calendar-days-gap)}.g-date-calendar__grid-rowgroup_mode_months,.g-date-calendar__grid-rowgroup_mode_quarters,.g-date-calendar__grid-rowgroup_mode_years{grid-row:1/-1;padding:12px 0 0}.g-date-calendar__grid-rowgroup-header{align-self:center}.g-date-calendar__grid-row{display:grid;gap:var(--_--calendar-days-gap);grid-auto-columns:1fr;grid-auto-flow:column}.g-date-calendar__weekday{align-items:center;display:flex;height:100%;justify-content:center;width:100%}.g-date-calendar__weekday_weekend{color:var(--g-color-text-danger)}.g-date-calendar__button{align-items:center;border-radius:4px;cursor:pointer;display:flex;font-weight:var(--g-text-subheader-font-weight);height:100%;justify-content:center;outline:none;position:relative;width:100%}.g-date-calendar__button:focus{box-shadow:0 0 0 2px var(--g-color-line-misc)}.g-date-calendar__button:focus:not(:focus-visible){box-shadow:none}.g-date-calendar__button:hover{background-color:var(--g-color-base-generic)}.g-date-calendar__button_selected[class]{background-color:var(--g-color-base-selection)}.g-date-calendar__button_selected.g-date-calendar__button_selection-end,.g-date-calendar__button_selected.g-date-calendar__button_selection-start{background-color:var(--g-color-base-brand)}.g-date-calendar__button_weekend{color:var(--g-color-text-danger)}.g-date-calendar__button_out-of-boundary{font-weight:var(--g-text-body-font-weight);opacity:.6}.g-date-calendar__button_current:before{background-color:currentColor;border-radius:50%;content:"";display:block;height:4px;inset-block-start:50%;position:absolute;transform:translateY(8px);width:4px}.g-date-calendar__button_disabled{font-weight:var(--g-text-body-font-weight);opacity:.6;pointer-events:none}.g-date-calendar__button_unavailable:not(.g-date-calendar__button_disabled){background-color:var(--g-color-base-generic);cursor:default;font-weight:var(--g-text-body-font-weight);opacity:.5}.g-date-date-field{display:inline-block;width:auto}.g-date-relative-range-date-picker{display:inline-flex;position:relative}.g-date-relative-range-date-picker__value-label{display:flex;width:100%}.g-date-relative-range-date-picker__value-label>div{flex:1 0}.g-date-relative-range-date-picker__value-label-content{display:flex;flex-direction:column}.g-date-relative-range-date-picker__value-label-tooltip{--g-popover-max-width:"none"}.g-date-relative-range-date-picker__value-label-item,.g-date-relative-range-date-picker__value-label-to,.g-date-relative-range-date-picker__value-label-tz{text-align:center}.g-date-relative-range-date-picker__value-label-tz{color:var(--g-color-text-hint);margin-block-start:5px}.g-tooltip[class]{--g-popup-border-width:0}.g-tooltip[class]>div{animation-duration:1ms;box-shadow:0 1px 5px 0 #00000026;box-sizing:border-box;max-width:360px;padding:4px 8px}.g-tooltip__content{-webkit-box-orient:vertical;-ms-box-orient:vertical;-webkit-line-clamp:20;-moz-line-clamp:20;-ms-line-clamp:20;display:-webkit-box;overflow:hidden;text-overflow:ellipsis}.g-spin{animation:g-spin 1s linear infinite;backface-visibility:hidden;display:inline-block}.g-spin__inner{border:2px solid var(--g-color-line-brand);border-end-end-radius:25px;border-inline-start:none;border-start-end-radius:25px;box-sizing:border-box;height:100%;margin-inline-start:50%;width:50%}.g-spin_size_xs{height:16px;width:16px}.g-spin_size_s{height:24px;width:24px}.g-spin_size_m{height:28px;width:28px}.g-spin_size_l{height:32px;width:32px}.g-spin_size_xl{height:36px;width:36px}@keyframes g-spin{0%{transform:rotate(0deg)}to{transform:rotate(1turn)}}.g-alert_corners_square{--g-card-border-radius:0}.g-alert__text-content{width:100%}.g-alert__actions_minContent{width:min-content}.g-alert__close-btn{flex-shrink:0}.monaco-editor .rendered-markdown kbd{border-bottom-color:var(--vscode-keybindingLabel-bottomBorder);border-width:1px}@font-face{font-display:block;font-family:codicon;src:url(../../static/media/codicon.f6283f7ccaed1249d9eb.ttf) format("truetype")}.context-view-block,.context-view-pointerBlock{cursor:auto;height:100%;left:0;position:fixed;top:0;width:100%}.action-widget .monaco-list-row.action .monaco-keybinding>.monaco-keybinding-key{border-bottom-color:var(--vscode-keybindingLabel-bottomBorder);border-width:1px}.monaco-editor,.monaco-editor-background{background-color:var(--vscode-editor-background)}.monaco-editor .margin-view-overlays .current-line,.monaco-editor .view-overlays .current-line{box-sizing:border-box;display:block;height:100%;left:0;position:absolute;top:0}.monaco-editor .mtkw,.monaco-editor .mtkz{color:var(--vscode-editorWhitespace-foreground)!important}.monaco-editor .minimap.slider-mouseover .minimap-slider.active,.monaco-editor .minimap.slider-mouseover:hover .minimap-slider{opacity:1}.monaco-editor .codelens-decoration>a:hover,.monaco-editor .codelens-decoration>a:hover .codicon{color:var(--vscode-editorLink-activeForeground)!important}.colorpicker-body .hue-strip{background:linear-gradient(180deg,red 0,#ff0 17%,#0f0 33%,#0ff 50%,#00f 67%,#f0f 83%,red)}.monaco-editor .inlineSuggestionsHints a,.monaco-editor .inlineSuggestionsHints a:hover{color:var(--vscode-foreground)}.monaco-hover ol,.monaco-hover ul{padding-left:20px}.monaco-editor .peekview-widget .head .peekview-title .dirname,.monaco-editor .peekview-widget .head .peekview-title .filename,.monaco-editor .peekview-widget .head .peekview-title .meta{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.hc-black .monaco-custom-toggle,.hc-black .monaco-custom-toggle:hover,.hc-light .monaco-custom-toggle,.hc-light .monaco-custom-toggle:hover{background:none}.monaco-editor .movedModified,.monaco-editor .movedOriginal{border:2px solid var(--vscode-diffEditor-move-border)}.monaco-scrollable-element.modified-in-monaco-diff-editor.vs .scrollbar,.monaco-scrollable-element.modified-in-monaco-diff-editor.vs-dark .scrollbar{background:#0000}.modified-in-monaco-diff-editor.hc-black .slider.active,.modified-in-monaco-diff-editor.hc-light .slider.active,.monaco-scrollable-element.modified-in-monaco-diff-editor.hc-black .scrollbar,.monaco-scrollable-element.modified-in-monaco-diff-editor.hc-light .scrollbar{background:none}.monaco-editor .inline-added-margin-view-zone,.monaco-editor .inline-deleted-margin-view-zone{text-align:right}.monaco-diff-editor .gutter{&>div{position:absolute}.gutterItem{opacity:0;transition:opacity .7s;&.showAlways{opacity:1}&.noTransition,&.showAlways{transition:none}}&:hover .gutterItem{opacity:1;transition:opacity .1s ease-in-out}.gutterItem{.background{border-left:2px solid var(--vscode-menu-border);height:100%;left:50%;position:absolute;width:1px}.buttons{align-items:center;display:flex;justify-content:center;position:absolute;width:100%;.monaco-toolbar{height:fit-content;.monaco-action-bar{line-height:1;.actions-container{background:var(--vscode-editorGutter-commentRangeForeground);border-radius:4px;width:fit-content;.action-item{&:hover{background:var(--vscode-toolbar-hoverBackground)}.action-label{padding:1px 2px}}}}}}}}.monaco-diff-editor .diff-hidden-lines-compact{.line-left,.line-right{border-top:1px solid;border-color:var(--vscode-editorCodeLens-foreground);height:1px;margin:auto;opacity:.5;width:100%}.line-left{width:20px}.text{text-wrap:nowrap;color:var(--vscode-editorCodeLens-foreground);font-size:11px;line-height:11px;margin:0 4px}}.monaco-editor .find-widget,.monaco-editor .findOptionsWidget{background-color:var(--vscode-editorWidget-background);box-shadow:0 0 8px 2px var(--vscode-widget-shadow);color:var(--vscode-editorWidget-foreground)}.monaco-editor .find-widget>.find-part .find-actions,.monaco-editor .find-widget>.replace-part .replace-actions{align-items:center;display:flex;height:25px}.monaco-editor .iPadShowKeyboard{background:url(data:image/svg+xml;base64,PHN2ZyB3aWR0aD0iNTMiIGhlaWdodD0iMzYiIGZpbGw9Im5vbmUiIHhtbG5zPSJodHRwOi8vd3d3LnczLm9yZy8yMDAwL3N2ZyI+PGcgY2xpcC1wYXRoPSJ1cmwoI2EpIj48cGF0aCBmaWxsLXJ1bGU9ImV2ZW5vZGQiIGNsaXAtcnVsZT0iZXZlbm9kZCIgZD0iTTQ4LjAzNiA0LjAxSDQuMDA4VjMyLjAzaDQ0LjAyOFY0LjAxWk00LjAwOC4wMDhBNC4wMDMgNC4wMDMgMCAwIDAgLjAwNSA0LjAxVjMyLjAzYTQuMDAzIDQuMDAzIDAgMCAwIDQuMDAzIDQuMDAyaDQ0LjAyOGE0LjAwMyA0LjAwMyAwIDAgMCA0LjAwMy00LjAwMlY0LjAxQTQuMDAzIDQuMDAzIDAgMCAwIDQ4LjAzNi4wMDhINC4wMDhaTTguMDEgOC4wMTNoNC4wMDN2NC4wMDNIOC4wMVY4LjAxM1ptMTIuMDA4IDBoLTQuMDAydjQuMDAzaDQuMDAyVjguMDEzWm00LjAwMyAwaDQuMDAydjQuMDAzaC00LjAwMlY4LjAxM1ptMTIuMDA4IDBoLTQuMDAzdjQuMDAzaDQuMDAzVjguMDEzWm00LjAwMiAwaDQuMDAzdjQuMDAzSDQwLjAzVjguMDEzWm0tMjQuMDE1IDguMDA1SDguMDF2NC4wMDNoOC4wMDZ2LTQuMDAzWm00LjAwMiAwaDQuMDAzdjQuMDAzaC00LjAwM3YtNC4wMDNabTEyLjAwOCAwaC00LjAwM3Y0LjAwM2g0LjAwM3YtNC4wMDNabTEyLjAwOCAwdjQuMDAzaC04LjAwNXYtNC4wMDNoOC4wMDVabS0zMi4wMjEgOC4wMDVIOC4wMXY0LjAwM2g0LjAwM3YtNC4wMDNabTQuMDAzIDBoMjAuMDEzdjQuMDAzSDE2LjAxNnYtNC4wMDNabTI4LjAxOCAwSDQwLjAzdjQuMDAzaDQuMDAzdi00LjAwM1oiIGZpbGw9IiM0MjQyNDIiLz48L2c+PGRlZnM+PGNsaXBQYXRoIGlkPSJhIj48cGF0aCBmaWxsPSIjZmZmIiBkPSJNMCAwaDUzdjM2SDB6Ii8+PC9jbGlwUGF0aD48L2RlZnM+PC9zdmc+) 50% no-repeat}.monaco-editor.vs-dark .iPadShowKeyboard{background:url(data:image/svg+xml;base64,PHN2ZyB3aWR0aD0iNTMiIGhlaWdodD0iMzYiIGZpbGw9Im5vbmUiIHhtbG5zPSJodHRwOi8vd3d3LnczLm9yZy8yMDAwL3N2ZyI+PGcgY2xpcC1wYXRoPSJ1cmwoI2EpIj48cGF0aCBmaWxsLXJ1bGU9ImV2ZW5vZGQiIGNsaXAtcnVsZT0iZXZlbm9kZCIgZD0iTTQ4LjAzNiA0LjAxSDQuMDA4VjMyLjAzaDQ0LjAyOFY0LjAxWk00LjAwOC4wMDhBNC4wMDMgNC4wMDMgMCAwIDAgLjAwNSA0LjAxVjMyLjAzYTQuMDAzIDQuMDAzIDAgMCAwIDQuMDAzIDQuMDAyaDQ0LjAyOGE0LjAwMyA0LjAwMyAwIDAgMCA0LjAwMy00LjAwMlY0LjAxQTQuMDAzIDQuMDAzIDAgMCAwIDQ4LjAzNi4wMDhINC4wMDhaTTguMDEgOC4wMTNoNC4wMDN2NC4wMDNIOC4wMVY4LjAxM1ptMTIuMDA4IDBoLTQuMDAydjQuMDAzaDQuMDAyVjguMDEzWm00LjAwMyAwaDQuMDAydjQuMDAzaC00LjAwMlY4LjAxM1ptMTIuMDA4IDBoLTQuMDAzdjQuMDAzaDQuMDAzVjguMDEzWm00LjAwMiAwaDQuMDAzdjQuMDAzSDQwLjAzVjguMDEzWm0tMjQuMDE1IDguMDA1SDguMDF2NC4wMDNoOC4wMDZ2LTQuMDAzWm00LjAwMiAwaDQuMDAzdjQuMDAzaC00LjAwM3YtNC4wMDNabTEyLjAwOCAwaC00LjAwM3Y0LjAwM2g0LjAwM3YtNC4wMDNabTEyLjAwOCAwdjQuMDAzaC04LjAwNXYtNC4wMDNoOC4wMDVabS0zMi4wMjEgOC4wMDVIOC4wMXY0LjAwM2g0LjAwM3YtNC4wMDNabTQuMDAzIDBoMjAuMDEzdjQuMDAzSDE2LjAxNnYtNC4wMDNabTI4LjAxOCAwSDQwLjAzdjQuMDAzaDQuMDAzdi00LjAwM1oiIGZpbGw9IiNDNUM1QzUiLz48L2c+PGRlZnM+PGNsaXBQYXRoIGlkPSJhIj48cGF0aCBmaWxsPSIjZmZmIiBkPSJNMCAwaDUzdjM2SDB6Ii8+PC9jbGlwUGF0aD48L2RlZnM+PC9zdmc+) 50% no-repeat}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.string-label)>.contents>.main>.right>.details-label,.monaco-editor .suggest-widget.docs-side .monaco-list .monaco-list-row.focused:not(.string-label)>.contents>.main>.right>.details-label,.monaco-editor .suggest-widget:not(.shows-details) .monaco-list .monaco-list-row.focused>.contents>.main>.right>.details-label{display:inline}.monaco-editor .suggest-details ol,.monaco-editor .suggest-details ul{padding-left:20px}.monaco-editor .inlineEditHints a,.monaco-editor .inlineEditHints a:hover{color:var(--vscode-foreground)}.monaco-editor div.inline-edits-widget{.promptEditor .monaco-editor{--vscode-editor-placeholder-foreground:var(--vscode-editorGhostText-foreground)}.promptEditor,.toolbar{opacity:0;transition:opacity .2s ease-in-out}&.focused,&:hover{.promptEditor,.toolbar{opacity:1}}.preview .monaco-editor{--vscode-editor-background:var(--widget-color);.mtk1{color:var(--vscode-editorGhostText-foreground)}.current-line-margin,.view-overlays .current-line-exact{border:none}}svg{.gradient-start{stop-color:var(--vscode-editor-background)}.gradient-stop{stop-color:var(--widget-color)}}}.monaco-editor{.editorPlaceholder{text-wrap:nowrap;color:var(--vscode-editor-placeholder-foreground);overflow:hidden;pointer-events:none;position:absolute;text-overflow:ellipsis;top:0}}.monaco-editor.hc-black .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-editor.hc-light .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-editor.vs-dark .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-menu .monaco-action-bar.vertical .action-item .action-menu-item:focus .action-label{stroke-width:1.2px}.monaco-diff-editor .synthetic-focus,.monaco-diff-editor [tabindex="-1"]:focus,.monaco-diff-editor [tabindex="0"]:focus,.monaco-diff-editor button:focus,.monaco-diff-editor input[type=button]:focus,.monaco-diff-editor input[type=checkbox]:focus,.monaco-diff-editor input[type=search]:focus,.monaco-diff-editor input[type=text]:focus,.monaco-diff-editor select:focus,.monaco-diff-editor textarea:focus,.monaco-editor{opacity:1;outline-color:var(--vscode-focusBorder);outline-offset:-1px;outline-style:solid;outline-width:1px}.quick-input-widget .monaco-highlighted-label .highlight{color:#0066bf}.vs .quick-input-widget .monaco-list-row.focused .monaco-highlighted-label .highlight{color:#9dddff}.vs-dark .quick-input-widget .monaco-highlighted-label .highlight{color:#0097fb}.hc-black .quick-input-widget .monaco-highlighted-label .highlight{color:#f38518}.hc-light .quick-input-widget .monaco-highlighted-label .highlight{color:#0f4a85}.monaco-keybinding>.monaco-keybinding-key{background-color:#ddd6;border-color:#ccc6 #ccc6 #bbb6;box-shadow:inset 0 -1px 0 #bbb6}.monaco-component.multiDiffEditor{>div{height:100%;left:0;position:absolute;top:0;width:100%;&.placeholder{display:grid;place-content:center;place-items:center;visibility:hidden;&.visible{visibility:visible}}}.active{--vscode-multiDiffEditor-border:var(--vscode-focusBorder)}.multiDiffEntry{display:flex;flex:1 1;flex-direction:column;overflow:hidden;.collapse-button{cursor:pointer;margin:0 5px;a{display:block}}.header{background:var(--vscode-editor-background);z-index:1000;&:not(.collapsed) .header-content{border-bottom:1px solid var(--vscode-sideBarSectionHeader-border)}.header-content{align-items:center;background:var(--vscode-multiDiffEditor-headerBackground);border-top:1px solid var(--vscode-multiDiffEditor-border);color:var(--vscode-foreground);display:flex;margin:8px 0 0;padding:4px 5px;&.shadow{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px}.file-path{display:flex;flex:1 1;min-width:0;.title{font-size:14px;line-height:22px;&.original{flex:1 1;min-width:0;text-overflow:ellipsis}}.status{font-weight:600;line-height:22px;margin:0 10px;opacity:.75}}.actions{padding:0 8px}}}.editorParent{border-bottom:1px solid var(--vscode-multiDiffEditor-border);display:flex;flex:1 1;flex-direction:column;overflow:hidden}.editorContainer{flex:1 1}}}.gt-table{border:none;border-collapse:initial;border-spacing:0}.gt-table__row_interactive{cursor:pointer}.gt-table__header_sticky{inset-block-start:0;position:sticky;z-index:1}.gt-table__footer_sticky{inset-block-end:0;position:sticky;z-index:1}.gt-table__cell{font-weight:400}.gt-table__footer-cell,.gt-table__header-cell{font-weight:500;position:relative}.gt-table__cell,.gt-table__footer-cell,.gt-table__header-cell{box-sizing:border-box;height:inherit;padding:0;text-align:start}.gt-table__cell_pinned,.gt-table__footer-cell_pinned,.gt-table__header-cell_pinned{position:sticky;z-index:1}.gt-table__sort{cursor:pointer;-webkit-user-select:none;user-select:none}.gt-table_with-row-virtualization{display:grid;height:auto}.gt-table_with-row-virtualization .gt-table__body{display:grid;position:relative}.gt-table_with-row-virtualization .gt-table__footer,.gt-table_with-row-virtualization .gt-table__header{display:grid}.gt-table_with-row-virtualization .gt-table__footer-row,.gt-table_with-row-virtualization .gt-table__header-row{display:flex;height:auto}.gt-table_with-row-virtualization .gt-table__row{display:flex;height:auto;position:absolute}.gt-table_with-row-virtualization .gt-table__row_empty{position:relative}.gt-group-header{inset-inline-start:0;margin:0;position:sticky}.gt-group-header__button{appearance:none;background:inherit;border:none;cursor:pointer;display:flex;gap:8px;outline:none;padding:0;width:100%}.gt-group-header__icon{display:inline-block;transform:rotate(-90deg);transition:transform .1s ease-out;vertical-align:middle}.gt-group-header__icon_expanded{transform:rotate(0)}.gt-group-header__content{display:inline-flex;font-weight:500;gap:4px}.gt-sort-indicator{color:var(--g-color-text-hint);display:inline-flex;margin-inline-start:4px;transform:rotate(0);vertical-align:middle}.gt-sort-indicator_invisible{opacity:0}.gt-table__header-cell:hover .gt-sort-indicator_invisible{opacity:1}.gt-sort-indicator_order_asc{transform:rotate(180deg)}.gt-resize-handle{background:#d3d3d3;cursor:col-resize;height:100%;inset-block-start:0;opacity:0;position:absolute;touch-action:none;-webkit-user-select:none;user-select:none;width:6px}.gt-resize-handle_direction_ltr{inset-inline-end:0}.gt-resize-handle_direction_rtl{inset-inline-start:0}.gt-resize-handle_resizing,.gt-table__header-cell:hover .gt-resize-handle{opacity:1} +/*!----------------------------------------------------------- + * Copyright (c) Microsoft Corporation. All rights reserved. + * Version: 0.52.2(404545bded1df6ffa41ea0af4e8ddb219018c6c1) + * Released under the MIT license + * https://github.com/microsoft/vscode/blob/main/LICENSE.txt + *-----------------------------------------------------------*/.monaco-action-bar{height:100%;white-space:nowrap}.monaco-action-bar .actions-container{align-items:center;display:flex;height:100%;margin:0 auto;padding:0;width:100%}.monaco-action-bar.vertical .actions-container{display:inline-block}.monaco-action-bar .action-item{align-items:center;cursor:pointer;display:block;justify-content:center;position:relative}.monaco-action-bar .action-item.disabled{cursor:default}.monaco-action-bar .action-item .codicon,.monaco-action-bar .action-item .icon{display:block}.monaco-action-bar .action-item .codicon{align-items:center;display:flex;height:16px;width:16px}.monaco-action-bar .action-label{border-radius:5px;display:flex;font-size:11px;padding:3px}.monaco-action-bar .action-item.disabled .action-label,.monaco-action-bar .action-item.disabled .action-label:before,.monaco-action-bar .action-item.disabled .action-label:hover{color:var(--vscode-disabledForeground)}.monaco-action-bar.vertical{text-align:left}.monaco-action-bar.vertical .action-item{display:block}.monaco-action-bar.vertical .action-label.separator{border-bottom:1px solid #bbb;display:block;margin-left:.8em;margin-right:.8em;padding-top:1px}.monaco-action-bar .action-item .action-label.separator{background-color:#bbb;cursor:default;height:16px;margin:5px 4px!important;min-width:1px;padding:0;width:1px}.secondary-actions .monaco-action-bar .action-label{margin-left:6px}.monaco-action-bar .action-item.select-container{align-items:center;display:flex;flex:1 1;justify-content:center;margin-right:10px;max-width:170px;min-width:60px;overflow:hidden}.monaco-action-bar .action-item.action-dropdown-item{display:flex}.monaco-action-bar .action-item.action-dropdown-item>.action-dropdown-item-separator{align-items:center;cursor:default;display:flex}.monaco-action-bar .action-item.action-dropdown-item>.action-dropdown-item-separator>div{width:1px}.monaco-aria-container{left:-999em;position:absolute}.monaco-text-button{align-items:center;border:1px solid var(--vscode-button-border,#0000);border-radius:2px;box-sizing:border-box;cursor:pointer;display:flex;justify-content:center;line-height:18px;padding:4px;text-align:center;width:100%}.monaco-text-button:focus{outline-offset:2px!important}.monaco-text-button:hover{text-decoration:none!important}.monaco-button.disabled,.monaco-button.disabled:focus{cursor:default;opacity:.4!important}.monaco-text-button .codicon{color:inherit!important;margin:0 .2em}.monaco-text-button.monaco-text-button-with-short-label{flex-direction:row;flex-wrap:wrap;height:28px;overflow:hidden;padding:0 4px}.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label{flex-basis:100%}.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label-short{flex-grow:1;overflow:hidden;width:0}.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label,.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label-short{align-items:center;display:flex;font-style:inherit;font-weight:400;justify-content:center;padding:4px 0}.monaco-button-dropdown{cursor:pointer;display:flex}.monaco-button-dropdown.disabled{cursor:default}.monaco-button-dropdown>.monaco-button:focus{outline-offset:-1px!important}.monaco-button-dropdown.disabled>.monaco-button-dropdown-separator,.monaco-button-dropdown.disabled>.monaco-button.disabled,.monaco-button-dropdown.disabled>.monaco-button.disabled:focus{opacity:.4!important}.monaco-button-dropdown>.monaco-button.monaco-text-button{border-right-width:0!important}.monaco-button-dropdown .monaco-button-dropdown-separator{cursor:default;padding:4px 0}.monaco-button-dropdown .monaco-button-dropdown-separator>div{height:100%;width:1px}.monaco-button-dropdown>.monaco-button.monaco-dropdown-button{align-items:center;border:1px solid var(--vscode-button-border,#0000);border-left-width:0!important;border-radius:0 2px 2px 0;display:flex}.monaco-button-dropdown>.monaco-button.monaco-text-button{border-radius:2px 0 0 2px}.monaco-description-button{align-items:center;display:flex;flex-direction:column;margin:4px 5px}.monaco-description-button .monaco-button-description{font-size:11px;font-style:italic;padding:4px 20px}.monaco-description-button .monaco-button-description,.monaco-description-button .monaco-button-label{align-items:center;display:flex;justify-content:center}.monaco-description-button .monaco-button-description>.codicon,.monaco-description-button .monaco-button-label>.codicon{color:inherit!important;margin:0 .2em}.monaco-button-dropdown.default-colors>.monaco-button,.monaco-button.default-colors{background-color:var(--vscode-button-background);color:var(--vscode-button-foreground)}.monaco-button-dropdown.default-colors>.monaco-button:hover,.monaco-button.default-colors:hover{background-color:var(--vscode-button-hoverBackground)}.monaco-button-dropdown.default-colors>.monaco-button.secondary,.monaco-button.default-colors.secondary{background-color:var(--vscode-button-secondaryBackground);color:var(--vscode-button-secondaryForeground)}.monaco-button-dropdown.default-colors>.monaco-button.secondary:hover,.monaco-button.default-colors.secondary:hover{background-color:var(--vscode-button-secondaryHoverBackground)}.monaco-button-dropdown.default-colors .monaco-button-dropdown-separator{background-color:var(--vscode-button-background);border-bottom:1px solid var(--vscode-button-border);border-top:1px solid var(--vscode-button-border)}.monaco-button-dropdown.default-colors .monaco-button.secondary+.monaco-button-dropdown-separator{background-color:var(--vscode-button-secondaryBackground)}.monaco-button-dropdown.default-colors .monaco-button-dropdown-separator>div{background-color:var(--vscode-button-separator)}@font-face{font-display:block;font-family:codicon;src:url(../../static/media/codicon.f6283f7ccaed1249d9eb.ttf) format("truetype")}.codicon[class*=codicon-]{-webkit-font-smoothing:antialiased;-moz-osx-font-smoothing:grayscale;display:inline-block;font:normal normal normal 16px/1 codicon;text-align:center;text-decoration:none;text-rendering:auto;text-transform:none;user-select:none;-webkit-user-select:none}.codicon-wrench-subaction{opacity:.5}@keyframes codicon-spin{to{transform:rotate(1turn)}}.codicon-gear.codicon-modifier-spin,.codicon-loading.codicon-modifier-spin,.codicon-notebook-state-executing.codicon-modifier-spin,.codicon-sync.codicon-modifier-spin{animation:codicon-spin 1.5s steps(30) infinite}.codicon-modifier-disabled{opacity:.4}.codicon-loading,.codicon-tree-item-loading:before{animation-duration:1s!important;animation-timing-function:cubic-bezier(.53,.21,.29,.67)!important}.context-view{position:absolute}.context-view.fixed{all:initial;color:inherit;font-family:inherit;font-size:13px;position:fixed}.monaco-count-badge{border-radius:11px;box-sizing:border-box;display:inline-block;font-size:11px;font-weight:400;line-height:11px;min-height:18px;min-width:18px;padding:3px 6px;text-align:center}.monaco-count-badge.long{border-radius:2px;line-height:normal;min-height:auto;padding:2px 3px}.monaco-dropdown{height:100%;padding:0}.monaco-dropdown>.dropdown-label{align-items:center;cursor:pointer;display:flex;height:100%;justify-content:center}.monaco-dropdown>.dropdown-label>.action-label.disabled{cursor:default}.monaco-dropdown-with-primary{border-radius:5px;display:flex!important;flex-direction:row}.monaco-dropdown-with-primary>.action-container>.action-label{margin-right:0}.monaco-dropdown-with-primary>.dropdown-action-container>.monaco-dropdown>.dropdown-label .codicon[class*=codicon-]{font-size:12px;line-height:16px;margin-left:-3px;padding-left:0;padding-right:0}.monaco-dropdown-with-primary>.dropdown-action-container>.monaco-dropdown>.dropdown-label>.action-label{background-position:50%;background-repeat:no-repeat;background-size:16px;display:block}.monaco-findInput{position:relative}.monaco-findInput .monaco-inputbox{font-size:13px;width:100%}.monaco-findInput>.controls{position:absolute;right:2px;top:3px}.vs .monaco-findInput.disabled{background-color:#e1e1e1}.vs-dark .monaco-findInput.disabled{background-color:#333}.hc-light .monaco-findInput.highlight-0 .controls,.monaco-findInput.highlight-0 .controls{animation:monaco-findInput-highlight-0 .1s linear 0s}.hc-light .monaco-findInput.highlight-1 .controls,.monaco-findInput.highlight-1 .controls{animation:monaco-findInput-highlight-1 .1s linear 0s}.hc-black .monaco-findInput.highlight-0 .controls,.vs-dark .monaco-findInput.highlight-0 .controls{animation:monaco-findInput-highlight-dark-0 .1s linear 0s}.hc-black .monaco-findInput.highlight-1 .controls,.vs-dark .monaco-findInput.highlight-1 .controls{animation:monaco-findInput-highlight-dark-1 .1s linear 0s}@keyframes monaco-findInput-highlight-0{0%{background:#fdff00cc}to{background:#0000}}@keyframes monaco-findInput-highlight-1{0%{background:#fdff00cc}99%{background:#0000}}@keyframes monaco-findInput-highlight-dark-0{0%{background:#ffffff70}to{background:#0000}}@keyframes monaco-findInput-highlight-dark-1{0%{background:#ffffff70}99%{background:#0000}}.monaco-hover{animation:fadein .1s linear;box-sizing:border-box;cursor:default;line-height:1.5em;overflow:hidden;position:absolute;user-select:text;-webkit-user-select:text;white-space:var(--vscode-hover-whiteSpace,normal)}.monaco-hover.hidden{display:none}.monaco-hover a:hover:not(.disabled){cursor:pointer}.monaco-hover .hover-contents:not(.html-hover-contents){padding:4px 8px}.monaco-hover .markdown-hover>.hover-contents:not(.code-hover-contents){word-wrap:break-word;max-width:var(--vscode-hover-maxWidth,500px)}.monaco-hover .markdown-hover>.hover-contents:not(.code-hover-contents) hr{min-width:100%}.monaco-hover .code,.monaco-hover h1,.monaco-hover h2,.monaco-hover h3,.monaco-hover h4,.monaco-hover h5,.monaco-hover h6,.monaco-hover p,.monaco-hover ul{margin:8px 0}.monaco-hover h1,.monaco-hover h2,.monaco-hover h3,.monaco-hover h4,.monaco-hover h5,.monaco-hover h6{line-height:1.1}.monaco-hover code{font-family:var(--monaco-monospace-font)}.monaco-hover hr{border-left:0;border-right:0;box-sizing:border-box;height:1px;margin:4px -8px -4px}.monaco-hover .code:first-child,.monaco-hover p:first-child,.monaco-hover ul:first-child{margin-top:0}.monaco-hover .code:last-child,.monaco-hover p:last-child,.monaco-hover ul:last-child{margin-bottom:0}.monaco-hover ol,.monaco-hover ul{padding-left:20px}.monaco-hover li>p{margin-bottom:0}.monaco-hover li>ul{margin-top:0}.monaco-hover code{border-radius:3px;padding:0 .4em}.monaco-hover .monaco-tokenized-source{white-space:var(--vscode-hover-sourceWhiteSpace,pre-wrap)}.monaco-hover .hover-row.status-bar{font-size:12px;line-height:22px}.monaco-hover .hover-row.status-bar .info{font-style:italic;padding:0 8px}.monaco-hover .hover-row.status-bar .actions{display:flex;padding:0 8px;width:100%}.monaco-hover .hover-row.status-bar .actions .action-container{cursor:pointer;margin-right:16px}.monaco-hover .hover-row.status-bar .actions .action-container .action .icon{padding-right:4px}.monaco-hover .hover-row.status-bar .actions .action-container a{color:var(--vscode-textLink-foreground);-webkit-text-decoration:var(--text-link-decoration);text-decoration:var(--text-link-decoration)}.monaco-hover .markdown-hover .hover-contents .codicon{color:inherit;font-size:inherit;vertical-align:middle}.monaco-hover .hover-contents a.code-link,.monaco-hover .hover-contents a.code-link:hover{color:inherit}.monaco-hover .hover-contents a.code-link:before{content:"("}.monaco-hover .hover-contents a.code-link:after{content:")"}.monaco-hover .hover-contents a.code-link>span{border-bottom:1px solid #0000;color:var(--vscode-textLink-foreground);text-decoration:underline;text-underline-position:under}.monaco-hover .hover-contents a.code-link>span:hover{color:var(--vscode-textLink-activeForeground)}.monaco-hover .markdown-hover .hover-contents:not(.code-hover-contents):not(.html-hover-contents) span{display:inline-block;margin-bottom:4px}.monaco-hover .markdown-hover .hover-contents:not(.code-hover-contents):not(.html-hover-contents) span.codicon{margin-bottom:2px}.monaco-hover-content .action-container a{-webkit-user-select:none;user-select:none}.monaco-hover-content .action-container.disabled{cursor:default;opacity:.4;pointer-events:none}.monaco-icon-label{display:flex;overflow:hidden;text-overflow:ellipsis}.monaco-icon-label:before{-webkit-font-smoothing:antialiased;-moz-osx-font-smoothing:grayscale;background-position:0;background-repeat:no-repeat;background-size:16px;display:inline-block;flex-shrink:0;height:22px;line-height:inherit!important;padding-right:6px;vertical-align:top;width:16px}.monaco-icon-label-iconpath{display:flex;height:16px;margin-top:2px;padding-left:2px;width:16px}.monaco-icon-label-container.disabled{color:var(--vscode-disabledForeground)}.monaco-icon-label>.monaco-icon-label-container{flex:1 1;min-width:0;overflow:hidden;text-overflow:ellipsis}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-name-container>.label-name{color:inherit;white-space:pre}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-name-container>.label-name>.label-separator{margin:0 2px;opacity:.5}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-suffix-container>.label-suffix{opacity:.7;white-space:pre}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-description-container>.label-description{font-size:.9em;margin-left:.5em;opacity:.7;white-space:pre}.monaco-icon-label.nowrap>.monaco-icon-label-container>.monaco-icon-description-container>.label-description{white-space:nowrap}.vs .monaco-icon-label>.monaco-icon-label-container>.monaco-icon-description-container>.label-description{opacity:.95}.monaco-icon-label.italic>.monaco-icon-label-container>.monaco-icon-description-container>.label-description,.monaco-icon-label.italic>.monaco-icon-label-container>.monaco-icon-name-container>.label-name{font-style:italic}.monaco-icon-label.deprecated{opacity:.66;text-decoration:line-through}.monaco-icon-label.italic:after{font-style:italic}.monaco-icon-label.strikethrough>.monaco-icon-label-container>.monaco-icon-description-container>.label-description,.monaco-icon-label.strikethrough>.monaco-icon-label-container>.monaco-icon-name-container>.label-name{text-decoration:line-through}.monaco-icon-label:after{font-size:90%;font-weight:600;margin:auto 16px 0 5px;opacity:.75;text-align:center}.monaco-list:focus .selected .monaco-icon-label,.monaco-list:focus .selected .monaco-icon-label:after{color:inherit!important}.monaco-list-row.focused.selected .label-description,.monaco-list-row.selected .label-description{opacity:.8}.monaco-inputbox{border-radius:2px;box-sizing:border-box;display:block;font-size:inherit;padding:0;position:relative}.monaco-inputbox>.ibwrapper>.input,.monaco-inputbox>.ibwrapper>.mirror{padding:4px 6px}.monaco-inputbox>.ibwrapper{height:100%;position:relative;width:100%}.monaco-inputbox>.ibwrapper>.input{border:none;box-sizing:border-box;color:inherit;display:inline-block;font-family:inherit;font-size:inherit;height:100%;line-height:inherit;resize:none;width:100%}.monaco-inputbox>.ibwrapper>input{text-overflow:ellipsis}.monaco-inputbox>.ibwrapper>textarea.input{display:block;outline:none;scrollbar-width:none}.monaco-inputbox>.ibwrapper>textarea.input::-webkit-scrollbar{display:none}.monaco-inputbox>.ibwrapper>textarea.input.empty{white-space:nowrap}.monaco-inputbox>.ibwrapper>.mirror{word-wrap:break-word;box-sizing:border-box;display:inline-block;left:0;position:absolute;top:0;visibility:hidden;white-space:pre-wrap;width:100%}.monaco-inputbox-container{text-align:right}.monaco-inputbox-container .monaco-inputbox-message{word-wrap:break-word;box-sizing:border-box;display:inline-block;font-size:12px;line-height:17px;margin-top:-1px;overflow:hidden;padding:.4em;text-align:left;width:100%}.monaco-inputbox .monaco-action-bar{position:absolute;right:2px;top:4px}.monaco-inputbox .monaco-action-bar .action-item{margin-left:2px}.monaco-inputbox .monaco-action-bar .action-item .codicon{background-repeat:no-repeat;height:16px;width:16px}.monaco-keybinding{align-items:center;display:flex;line-height:10px}.monaco-keybinding>.monaco-keybinding-key{border-radius:3px;border-style:solid;border-width:1px;display:inline-block;font-size:11px;margin:0 2px;padding:3px 5px;vertical-align:middle}.monaco-keybinding>.monaco-keybinding-key:first-child{margin-left:0}.monaco-keybinding>.monaco-keybinding-key:last-child{margin-right:0}.monaco-keybinding>.monaco-keybinding-key-separator{display:inline-block}.monaco-keybinding>.monaco-keybinding-key-chord-separator{width:6px}.monaco-list{height:100%;position:relative;white-space:nowrap;width:100%}.monaco-list.mouse-support{user-select:none;-webkit-user-select:none}.monaco-list>.monaco-scrollable-element{height:100%}.monaco-list-rows{height:100%;position:relative;width:100%}.monaco-list.horizontal-scrolling .monaco-list-rows{min-width:100%;width:auto}.monaco-list-row{box-sizing:border-box;overflow:hidden;position:absolute;width:100%}.monaco-list.mouse-support .monaco-list-row{cursor:pointer;touch-action:none}.monaco-list .monaco-scrollable-element>.scrollbar.vertical,.monaco-pane-view>.monaco-split-view2.vertical>.monaco-scrollable-element>.scrollbar.vertical{z-index:14}.monaco-list-row.scrolling{display:none!important}.monaco-list.element-focused,.monaco-list.selection-multiple,.monaco-list.selection-single{outline:0!important}.monaco-drag-image{border-radius:10px;display:inline-block;font-size:12px;padding:1px 7px;position:absolute;z-index:1000}.monaco-list-type-filter-message{box-sizing:border-box;height:100%;left:0;opacity:.7;padding:40px 1em 1em;pointer-events:none;position:absolute;text-align:center;top:0;white-space:normal;width:100%}.monaco-list-type-filter-message:empty{display:none}.monaco-mouse-cursor-text{cursor:text}.monaco-progress-container{height:2px;overflow:hidden;width:100%}.monaco-progress-container .progress-bit{display:none;height:2px;left:0;position:absolute;width:2%}.monaco-progress-container.active .progress-bit{display:inherit}.monaco-progress-container.discrete .progress-bit{left:0;transition:width .1s linear}.monaco-progress-container.discrete.done .progress-bit{width:100%}.monaco-progress-container.infinite .progress-bit{animation-duration:4s;animation-iteration-count:infinite;animation-name:progress;animation-timing-function:linear;transform:translateZ(0)}.monaco-progress-container.infinite.infinite-long-running .progress-bit{animation-timing-function:steps(100)}@keyframes progress{0%{transform:translateX(0) scaleX(1)}50%{transform:translateX(2500%) scaleX(3)}to{transform:translateX(4900%) scaleX(1)}}:root{--vscode-sash-size:4px;--vscode-sash-hover-size:4px}.monaco-sash{position:absolute;touch-action:none;z-index:35}.monaco-sash.disabled{pointer-events:none}.monaco-sash.mac.vertical{cursor:col-resize}.monaco-sash.vertical.minimum{cursor:e-resize}.monaco-sash.vertical.maximum{cursor:w-resize}.monaco-sash.mac.horizontal{cursor:row-resize}.monaco-sash.horizontal.minimum{cursor:s-resize}.monaco-sash.horizontal.maximum{cursor:n-resize}.monaco-sash.disabled{cursor:default!important;pointer-events:none!important}.monaco-sash.vertical{cursor:ew-resize;height:100%;top:0;width:var(--vscode-sash-size)}.monaco-sash.horizontal{cursor:ns-resize;height:var(--vscode-sash-size);left:0;width:100%}.monaco-sash:not(.disabled)>.orthogonal-drag-handle{content:" ";cursor:all-scroll;display:block;height:calc(var(--vscode-sash-size)*2);position:absolute;width:calc(var(--vscode-sash-size)*2);z-index:100}.monaco-sash.horizontal.orthogonal-edge-north:not(.disabled)>.orthogonal-drag-handle.start,.monaco-sash.horizontal.orthogonal-edge-south:not(.disabled)>.orthogonal-drag-handle.end{cursor:nwse-resize}.monaco-sash.horizontal.orthogonal-edge-north:not(.disabled)>.orthogonal-drag-handle.end,.monaco-sash.horizontal.orthogonal-edge-south:not(.disabled)>.orthogonal-drag-handle.start{cursor:nesw-resize}.monaco-sash.vertical>.orthogonal-drag-handle.start{left:calc(var(--vscode-sash-size)*-.5);top:calc(var(--vscode-sash-size)*-1)}.monaco-sash.vertical>.orthogonal-drag-handle.end{bottom:calc(var(--vscode-sash-size)*-1);left:calc(var(--vscode-sash-size)*-.5)}.monaco-sash.horizontal>.orthogonal-drag-handle.start{left:calc(var(--vscode-sash-size)*-1);top:calc(var(--vscode-sash-size)*-.5)}.monaco-sash.horizontal>.orthogonal-drag-handle.end{right:calc(var(--vscode-sash-size)*-1);top:calc(var(--vscode-sash-size)*-.5)}.monaco-sash:before{background:#0000;content:"";height:100%;pointer-events:none;position:absolute;width:100%}.monaco-workbench:not(.reduce-motion) .monaco-sash:before{transition:background-color .1s ease-out}.monaco-sash.active:before,.monaco-sash.hover:before{background:var(--vscode-sash-hoverBorder)}.monaco-sash.vertical:before{left:calc(50% - var(--vscode-sash-hover-size)/2);width:var(--vscode-sash-hover-size)}.monaco-sash.horizontal:before{height:var(--vscode-sash-hover-size);top:calc(50% - var(--vscode-sash-hover-size)/2)}.pointer-events-disabled{pointer-events:none!important}.monaco-sash.debug{background:cyan}.monaco-sash.debug.disabled{background:#0ff3}.monaco-sash.debug:not(.disabled)>.orthogonal-drag-handle{background:red}.monaco-scrollable-element>.scrollbar>.scra{cursor:pointer;font-size:11px!important}.monaco-scrollable-element>.visible{background:#0000;opacity:1;transition:opacity .1s linear;z-index:11}.monaco-scrollable-element>.invisible{opacity:0;pointer-events:none}.monaco-scrollable-element>.invisible.fade{transition:opacity .8s linear}.monaco-scrollable-element>.shadow{display:none;position:absolute}.monaco-scrollable-element>.shadow.top{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px inset;display:block;height:3px;left:3px;top:0;width:100%}.monaco-scrollable-element>.shadow.left{box-shadow:var(--vscode-scrollbar-shadow) 6px 0 6px -6px inset;display:block;height:100%;left:0;top:3px;width:3px}.monaco-scrollable-element>.shadow.top-left-corner{display:block;height:3px;left:0;top:0;width:3px}.monaco-scrollable-element>.shadow.top.left{box-shadow:var(--vscode-scrollbar-shadow) 6px 0 6px -6px inset}.monaco-scrollable-element>.scrollbar>.slider{background:var(--vscode-scrollbarSlider-background)}.monaco-scrollable-element>.scrollbar>.slider:hover{background:var(--vscode-scrollbarSlider-hoverBackground)}.monaco-scrollable-element>.scrollbar>.slider.active{background:var(--vscode-scrollbarSlider-activeBackground)}.monaco-select-box{border-radius:2px;cursor:pointer;width:100%}.monaco-select-box-dropdown-container{font-size:13px;font-weight:400;text-transform:none}.monaco-action-bar .action-item.select-container{cursor:default}.monaco-action-bar .action-item .monaco-select-box{cursor:pointer;min-height:18px;min-width:100px;padding:2px 23px 2px 8px}.mac .monaco-action-bar .action-item .monaco-select-box{border-radius:5px;font-size:11px}.monaco-select-box-dropdown-padding{--dropdown-padding-top:1px;--dropdown-padding-bottom:1px}.hc-black .monaco-select-box-dropdown-padding,.hc-light .monaco-select-box-dropdown-padding{--dropdown-padding-top:3px;--dropdown-padding-bottom:4px}.monaco-select-box-dropdown-container{box-sizing:border-box;display:none}.monaco-select-box-dropdown-container>.select-box-details-pane>.select-box-description-markdown *{margin:0}.monaco-select-box-dropdown-container>.select-box-details-pane>.select-box-description-markdown a:focus{outline:1px solid -webkit-focus-ring-color;outline-offset:-1px}.monaco-select-box-dropdown-container>.select-box-details-pane>.select-box-description-markdown code{font-family:var(--monaco-monospace-font);line-height:15px}.monaco-select-box-dropdown-container.visible{border-bottom-left-radius:3px;border-bottom-right-radius:3px;display:flex;flex-direction:column;overflow:hidden;text-align:left;width:1px}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container{align-self:flex-start;box-sizing:border-box;flex:0 0 auto;overflow:hidden;padding-bottom:var(--dropdown-padding-bottom);padding-left:1px;padding-right:1px;padding-top:var(--dropdown-padding-top);width:100%}.monaco-select-box-dropdown-container>.select-box-details-pane{padding:5px}.hc-black .monaco-select-box-dropdown-container>.select-box-dropdown-list-container{padding-bottom:var(--dropdown-padding-bottom);padding-top:var(--dropdown-padding-top)}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row{cursor:pointer}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.option-text{float:left;overflow:hidden;padding-left:3.5px;text-overflow:ellipsis;white-space:nowrap}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.option-detail{float:left;opacity:.7;overflow:hidden;padding-left:3.5px;text-overflow:ellipsis;white-space:nowrap}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.option-decorator-right{float:right;overflow:hidden;padding-right:10px;text-overflow:ellipsis;white-space:nowrap}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.visually-hidden{height:1px;left:-10000px;overflow:hidden;position:absolute;top:auto;width:1px}.monaco-select-box-dropdown-container>.select-box-dropdown-container-width-control{align-self:flex-start;flex:1 1 auto;opacity:0}.monaco-select-box-dropdown-container>.select-box-dropdown-container-width-control>.width-control-div{max-height:0;overflow:hidden}.monaco-select-box-dropdown-container>.select-box-dropdown-container-width-control>.width-control-div>.option-text-width-control{padding-left:4px;padding-right:8px;white-space:nowrap}.monaco-split-view2{height:100%;position:relative;width:100%}.monaco-split-view2>.sash-container{height:100%;pointer-events:none;position:absolute;width:100%}.monaco-split-view2>.sash-container>.monaco-sash{pointer-events:auto}.monaco-split-view2>.monaco-scrollable-element{height:100%;width:100%}.monaco-split-view2>.monaco-scrollable-element>.split-view-container{height:100%;position:relative;white-space:nowrap;width:100%}.monaco-split-view2>.monaco-scrollable-element>.split-view-container>.split-view-view{position:absolute;white-space:normal}.monaco-split-view2>.monaco-scrollable-element>.split-view-container>.split-view-view:not(.visible){display:none}.monaco-split-view2.vertical>.monaco-scrollable-element>.split-view-container>.split-view-view{width:100%}.monaco-split-view2.horizontal>.monaco-scrollable-element>.split-view-container>.split-view-view{height:100%}.monaco-split-view2.separator-border>.monaco-scrollable-element>.split-view-container>.split-view-view:not(:first-child):before{background-color:var(--separator-border);content:" ";left:0;pointer-events:none;position:absolute;top:0;z-index:5}.monaco-split-view2.separator-border.horizontal>.monaco-scrollable-element>.split-view-container>.split-view-view:not(:first-child):before{height:100%;width:1px}.monaco-split-view2.separator-border.vertical>.monaco-scrollable-element>.split-view-container>.split-view-view:not(:first-child):before{height:1px;width:100%}.monaco-table{display:flex;flex-direction:column;height:100%;overflow:hidden;position:relative;white-space:nowrap;width:100%}.monaco-table>.monaco-split-view2{border-bottom:1px solid #0000}.monaco-table>.monaco-list{flex:1 1}.monaco-table-tr{display:flex;height:100%}.monaco-table-th{font-weight:700;height:100%;overflow:hidden;text-overflow:ellipsis;width:100%}.monaco-table-td,.monaco-table-th{box-sizing:border-box;flex-shrink:0;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-table>.monaco-split-view2 .monaco-sash.vertical:before{border-left:1px solid #0000;content:"";left:calc(var(--vscode-sash-size)/2);position:absolute;width:0}.monaco-workbench:not(.reduce-motion) .monaco-table>.monaco-split-view2,.monaco-workbench:not(.reduce-motion) .monaco-table>.monaco-split-view2 .monaco-sash.vertical:before{transition:border-color .2s ease-out}.monaco-custom-toggle{border:1px solid #0000;border-radius:3px;box-sizing:border-box;cursor:pointer;float:left;height:20px;margin-left:2px;overflow:hidden;padding:1px;user-select:none;-webkit-user-select:none;width:20px}.monaco-custom-toggle:hover{background-color:var(--vscode-inputOption-hoverBackground)}.hc-black .monaco-custom-toggle:hover,.hc-light .monaco-custom-toggle:hover{border:1px dashed var(--vscode-focusBorder)}.hc-black .monaco-custom-toggle,.hc-black .monaco-custom-toggle:hover,.hc-light .monaco-custom-toggle,.hc-light .monaco-custom-toggle:hover{background:none}.monaco-custom-toggle.monaco-checkbox{background-size:16px!important;border:1px solid #0000;border-radius:3px;height:18px;margin-left:0;margin-right:9px;opacity:1;padding:0;width:18px}.monaco-action-bar .checkbox-action-item{align-items:center;border-radius:2px;display:flex;padding-right:2px}.monaco-action-bar .checkbox-action-item:hover{background-color:var(--vscode-toolbar-hoverBackground)}.monaco-action-bar .checkbox-action-item>.monaco-custom-toggle.monaco-checkbox{margin-right:4px}.monaco-action-bar .checkbox-action-item>.checkbox-label{font-size:12px}.monaco-custom-toggle.monaco-checkbox:not(.checked):before{visibility:hidden}.monaco-toolbar{height:100%}.monaco-toolbar .toolbar-toggle-more{display:inline-block;padding:0}.monaco-tl-row{align-items:center;display:flex;height:100%;position:relative}.monaco-tl-row.disabled{cursor:default}.monaco-tl-indent{height:100%;left:16px;pointer-events:none;position:absolute;top:0}.hide-arrows .monaco-tl-indent{left:12px}.monaco-tl-indent>.indent-guide{border-left:1px solid #0000;box-sizing:border-box;display:inline-block;height:100%}.monaco-workbench:not(.reduce-motion) .monaco-tl-indent>.indent-guide{transition:border-color .1s linear}.monaco-tl-contents,.monaco-tl-twistie{height:100%}.monaco-tl-twistie{align-items:center;display:flex!important;flex-shrink:0;font-size:10px;justify-content:center;padding-right:6px;text-align:right;transform:translateX(3px);width:16px}.monaco-tl-contents{flex:1 1;overflow:hidden}.monaco-tl-twistie:before{border-radius:20px}.monaco-tl-twistie.collapsed:before{transform:rotate(-90deg)}.monaco-tl-twistie.codicon-tree-item-loading:before{animation:codicon-spin 1.25s steps(30) infinite}.monaco-tree-type-filter{border:1px solid var(--vscode-widget-border);border-bottom-left-radius:4px;border-bottom-right-radius:4px;display:flex;margin:0 6px;max-width:200px;padding:3px;position:absolute;top:0;z-index:100}.monaco-workbench:not(.reduce-motion) .monaco-tree-type-filter{transition:top .3s}.monaco-tree-type-filter.disabled{top:-40px!important}.monaco-tree-type-filter-grab{align-items:center;cursor:grab;display:flex!important;justify-content:center;margin-right:2px}.monaco-tree-type-filter-grab.grabbing{cursor:grabbing}.monaco-tree-type-filter-input{flex:1 1}.monaco-tree-type-filter-input .monaco-inputbox{height:23px}.monaco-tree-type-filter-input .monaco-inputbox>.ibwrapper>.input,.monaco-tree-type-filter-input .monaco-inputbox>.ibwrapper>.mirror{padding:2px 4px}.monaco-tree-type-filter-input .monaco-findInput>.controls{top:2px}.monaco-tree-type-filter-actionbar{margin-left:4px}.monaco-tree-type-filter-actionbar .monaco-action-bar .action-label{padding:2px}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container{background-color:var(--vscode-sideBar-background);height:0;left:0;position:absolute;top:0;width:100%;z-index:13}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-row.monaco-list-row{background-color:var(--vscode-sideBar-background);opacity:1!important;overflow:hidden;position:absolute;width:100%}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-row:hover{background-color:var(--vscode-list-hoverBackground)!important;cursor:pointer}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container.empty,.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container.empty .monaco-tree-sticky-container-shadow{display:none}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-container-shadow{bottom:-3px;height:0;left:0;position:absolute;width:100%}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container[tabindex="0"]:focus{outline:none}.monaco-editor .inputarea{background-color:initial;border:none;color:#0000;margin:0;min-height:0;min-width:0;outline:none!important;overflow:hidden;padding:0;position:absolute;resize:none;z-index:-10}.monaco-editor .inputarea.ime-input{caret-color:var(--vscode-editorCursor-foreground);color:var(--vscode-editor-foreground);z-index:10}.monaco-workbench .workbench-hover{background:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);border-radius:3px;box-shadow:0 2px 8px var(--vscode-widget-shadow);color:var(--vscode-editorHoverWidget-foreground);font-size:13px;line-height:19px;max-width:700px;overflow:hidden;position:relative;z-index:40}.monaco-workbench .workbench-hover hr{border-bottom:none}.monaco-workbench .workbench-hover:not(.skip-fade-in){animation:fadein .1s linear}.monaco-workbench .workbench-hover.compact{font-size:12px}.monaco-workbench .workbench-hover.compact .hover-contents{padding:2px 8px}.monaco-workbench .workbench-hover-container.locked .workbench-hover{outline:1px solid var(--vscode-editorHoverWidget-border)}.monaco-workbench .workbench-hover-container.locked .workbench-hover:focus,.monaco-workbench .workbench-hover-lock:focus{outline:1px solid var(--vscode-focusBorder)}.monaco-workbench .workbench-hover-container.locked .workbench-hover-lock:hover{background:var(--vscode-toolbar-hoverBackground)}.monaco-workbench .workbench-hover-pointer{pointer-events:none;position:absolute;z-index:41}.monaco-workbench .workbench-hover-pointer:after{background-color:var(--vscode-editorHoverWidget-background);border-bottom:1px solid var(--vscode-editorHoverWidget-border);border-right:1px solid var(--vscode-editorHoverWidget-border);content:"";height:5px;position:absolute;width:5px}.monaco-workbench .locked .workbench-hover-pointer:after{border-bottom-width:2px;border-right-width:2px;height:4px;width:4px}.monaco-workbench .workbench-hover-pointer.left{left:-3px}.monaco-workbench .workbench-hover-pointer.right{right:3px}.monaco-workbench .workbench-hover-pointer.top{top:-3px}.monaco-workbench .workbench-hover-pointer.bottom{bottom:3px}.monaco-workbench .workbench-hover-pointer.left:after{transform:rotate(135deg)}.monaco-workbench .workbench-hover-pointer.right:after{transform:rotate(315deg)}.monaco-workbench .workbench-hover-pointer.top:after{transform:rotate(225deg)}.monaco-workbench .workbench-hover-pointer.bottom:after{transform:rotate(45deg)}.monaco-workbench .workbench-hover a{color:var(--vscode-textLink-foreground)}.monaco-workbench .workbench-hover a:focus{outline:1px solid;outline-color:var(--vscode-focusBorder);outline-offset:-1px;text-decoration:underline}.monaco-workbench .workbench-hover a:active,.monaco-workbench .workbench-hover a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-workbench .workbench-hover code{background:var(--vscode-textCodeBlock-background)}.monaco-workbench .workbench-hover .hover-row .actions{background:var(--vscode-editorHoverWidget-statusBarBackground)}.monaco-workbench .workbench-hover.right-aligned{left:1px}.monaco-workbench .workbench-hover.right-aligned .hover-row.status-bar .actions{flex-direction:row-reverse}.monaco-workbench .workbench-hover.right-aligned .hover-row.status-bar .actions .action-container{margin-left:16px;margin-right:0}.monaco-editor .blockDecorations-container{pointer-events:none;position:absolute;top:0}.monaco-editor .blockDecorations-block{box-sizing:border-box;position:absolute}.monaco-editor .margin-view-overlays .current-line,.monaco-editor .view-overlays .current-line{box-sizing:border-box;display:block;height:100%;left:0;position:absolute;top:0}.monaco-editor + .margin-view-overlays + .current-line.current-line-margin.current-line-margin-both{border-right:0}.monaco-editor .lines-content .cdr{height:100%;position:absolute}.monaco-editor .glyph-margin{position:absolute;top:0}.monaco-editor .glyph-margin-widgets .cgmr{align-items:center;display:flex;justify-content:center;position:absolute}.monaco-editor .glyph-margin-widgets .cgmr.codicon-modifier-spin:before{left:50%;position:absolute;top:50%;transform:translate(-50%,-50%)}.monaco-editor .lines-content .core-guide{box-sizing:border-box;height:100%;position:absolute}.monaco-editor .margin-view-overlays .line-numbers{font-feature-settings:"tnum";bottom:0;box-sizing:border-box;cursor:default;display:inline-block;font-variant-numeric:tabular-nums;position:absolute;text-align:right;vertical-align:middle}.monaco-editor .relative-current-line-number{display:inline-block;text-align:left;width:100%}.monaco-editor .margin-view-overlays .line-numbers.lh-odd{margin-top:1px}.monaco-editor .line-numbers{color:var(--vscode-editorLineNumber-foreground)}.monaco-editor .line-numbers.active-line-number{color:var(--vscode-editorLineNumber-activeForeground)}.mtkcontrol{background:#960000!important;color:#fff!important}.mtkoverflow{background-color:var(--vscode-button-background,var(--vscode-editor-background));border-color:var(--vscode-contrastBorder);border-radius:2px;border-style:solid;border-width:1px;color:var(--vscode-button-foreground,var(--vscode-editor-foreground));cursor:pointer;padding:4px}.mtkoverflow:hover{background-color:var(--vscode-button-hoverBackground)}.monaco-editor.no-user-select .lines-content,.monaco-editor.no-user-select .view-line,.monaco-editor.no-user-select .view-lines{user-select:none;-webkit-user-select:none}.monaco-editor.mac .lines-content:hover,.monaco-editor.mac .view-line:hover,.monaco-editor.mac .view-lines:hover{user-select:text;-webkit-user-select:text;-ms-user-select:text}.monaco-editor.enable-user-select{user-select:auto;-webkit-user-select:initial}.monaco-editor .view-lines{white-space:nowrap}.monaco-editor .view-line{position:absolute;width:100%}.monaco-editor .lines-content>.view-lines>.view-line>span{bottom:0;position:absolute;top:0}.monaco-editor .mtkw,.monaco-editor .mtkz{color:var(--vscode-editorWhitespace-foreground)!important}.monaco-editor .mtkz{display:inline-block}.monaco-editor .lines-decorations{background:#fff;position:absolute;top:0}.monaco-editor .margin-view-overlays .cldr{height:100%;position:absolute}.monaco-editor .margin{background-color:var(--vscode-editorGutter-background)}.monaco-editor .margin-view-overlays .cmdr{height:100%;left:0;position:absolute;width:100%}.monaco-editor .minimap.slider-mouseover .minimap-slider{opacity:0;transition:opacity .1s linear}.monaco-editor .minimap.slider-mouseover .minimap-slider.active,.monaco-editor .minimap.slider-mouseover:hover .minimap-slider{opacity:1}.monaco-editor .minimap-slider .minimap-slider-horizontal{background:var(--vscode-minimapSlider-background)}.monaco-editor .minimap-slider:hover .minimap-slider-horizontal{background:var(--vscode-minimapSlider-hoverBackground)}.monaco-editor .minimap-slider.active .minimap-slider-horizontal{background:var(--vscode-minimapSlider-activeBackground)}.monaco-editor .minimap-shadow-visible{box-shadow:var(--vscode-scrollbar-shadow) -6px 0 6px -6px inset}.monaco-editor .minimap-shadow-hidden{position:absolute;width:0}.monaco-editor .minimap-shadow-visible{left:-6px;position:absolute;width:6px}.monaco-editor.no-minimap-shadow .minimap-shadow-visible{left:-1px;position:absolute;width:1px}.minimap.autohide{opacity:0;transition:opacity .5s}.minimap.autohide:hover{opacity:1}.monaco-editor .minimap{z-index:5}.monaco-editor .overlayWidgets{left:0;position:absolute;top:0}.monaco-editor .view-ruler{box-shadow:1px 0 0 0 var(--vscode-editorRuler-foreground) inset;position:absolute;top:0}.monaco-editor .scroll-decoration{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px inset;height:6px;left:0;position:absolute;top:0}.monaco-editor .lines-content .cslr{position:absolute}.monaco-editor .focused .selected-text{background-color:var(--vscode-editor-selectionBackground)}.monaco-editor .selected-text{background-color:var(--vscode-editor-inactiveSelectionBackground)}.monaco-editor .top-left-radius{border-top-left-radius:3px}.monaco-editor .bottom-left-radius{border-bottom-left-radius:3px}.monaco-editor .top-right-radius{border-top-right-radius:3px}.monaco-editor .bottom-right-radius{border-bottom-right-radius:3px}.monaco-editor.hc-black .top-left-radius{border-top-left-radius:0}.monaco-editor.hc-black .bottom-left-radius{border-bottom-left-radius:0}.monaco-editor.hc-black .top-right-radius{border-top-right-radius:0}.monaco-editor.hc-black .bottom-right-radius{border-bottom-right-radius:0}.monaco-editor.hc-light .top-left-radius{border-top-left-radius:0}.monaco-editor.hc-light .bottom-left-radius{border-bottom-left-radius:0}.monaco-editor.hc-light .top-right-radius{border-top-right-radius:0}.monaco-editor.hc-light .bottom-right-radius{border-bottom-right-radius:0}.monaco-editor .cursors-layer{position:absolute;top:0}.monaco-editor .cursors-layer>.cursor{box-sizing:border-box;overflow:hidden;position:absolute}.monaco-editor .cursors-layer.cursor-smooth-caret-animation>.cursor{transition:all 80ms}.monaco-editor .cursors-layer.cursor-block-outline-style>.cursor{background:#0000!important;border-style:solid;border-width:1px}.monaco-editor .cursors-layer.cursor-underline-style>.cursor{background:#0000!important;border-bottom-style:solid;border-bottom-width:2px}.monaco-editor .cursors-layer.cursor-underline-thin-style>.cursor{background:#0000!important;border-bottom-style:solid;border-bottom-width:1px}@keyframes monaco-cursor-smooth{0%,20%{opacity:1}60%,to{opacity:0}}@keyframes monaco-cursor-phase{0%,20%{opacity:1}90%,to{opacity:0}}@keyframes monaco-cursor-expand{0%,20%{transform:scaleY(1)}80%,to{transform:scaleY(0)}}.cursor-smooth{animation:monaco-cursor-smooth .5s ease-in-out 0s 20 alternate}.cursor-phase{animation:monaco-cursor-phase .5s ease-in-out 0s 20 alternate}.cursor-expand>.cursor{animation:monaco-cursor-expand .5s ease-in-out 0s 20 alternate}.monaco-editor .mwh{color:var(--vscode-editorWhitespace-foreground)!important;position:absolute}::-ms-clear{display:none}.monaco-editor .editor-widget input{color:inherit}.monaco-editor{-webkit-text-size-adjust:100%;color:var(--vscode-editor-foreground);overflow:visible;overflow-wrap:normal;position:relative}.monaco-editor,.monaco-editor-background{background-color:var(--vscode-editor-background)}.monaco-editor .rangeHighlight{background-color:var(--vscode-editor-rangeHighlightBackground);border:1px solid var(--vscode-editor-rangeHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .rangeHighlight,.monaco-editor.hc-light .rangeHighlight{border-style:dotted}.monaco-editor .symbolHighlight{background-color:var(--vscode-editor-symbolHighlightBackground);border:1px solid var(--vscode-editor-symbolHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .symbolHighlight,.monaco-editor.hc-light .symbolHighlight{border-style:dotted}.monaco-editor .overflow-guard{overflow:hidden;position:relative}.monaco-editor .view-overlays{position:absolute;top:0}.monaco-editor .margin-view-overlays>div,.monaco-editor .view-overlays>div{position:absolute;width:100%}.monaco-editor .squiggly-error{border-bottom:4px double var(--vscode-editorError-border)}.monaco-editor .squiggly-error:before{background:var(--vscode-editorError-background);content:"";display:block;height:100%;width:100%}.monaco-editor .squiggly-warning{border-bottom:4px double var(--vscode-editorWarning-border)}.monaco-editor .squiggly-warning:before{background:var(--vscode-editorWarning-background);content:"";display:block;height:100%;width:100%}.monaco-editor .squiggly-info{border-bottom:4px double var(--vscode-editorInfo-border)}.monaco-editor .squiggly-info:before{background:var(--vscode-editorInfo-background);content:"";display:block;height:100%;width:100%}.monaco-editor .squiggly-hint{border-bottom:2px dotted var(--vscode-editorHint-border)}.monaco-editor.showUnused .squiggly-unnecessary{border-bottom:2px dashed var(--vscode-editorUnnecessaryCode-border)}.monaco-editor.showDeprecated .squiggly-inline-deprecated{text-decoration:line-through;text-decoration-color:var(--vscode-editor-foreground,inherit)}.monaco-component.diff-review{user-select:none;-webkit-user-select:none;z-index:99}.monaco-diff-editor .diff-review{position:absolute}.monaco-component.diff-review .diff-review-line-number{color:var(--vscode-editorLineNumber-foreground);display:inline-block;text-align:right}.monaco-component.diff-review .diff-review-summary{padding-left:10px}.monaco-component.diff-review .diff-review-shadow{box-shadow:var(--vscode-scrollbar-shadow) 0 -6px 6px -6px inset;position:absolute}.monaco-component.diff-review .diff-review-row{white-space:pre}.monaco-component.diff-review .diff-review-table{display:table;min-width:100%}.monaco-component.diff-review .diff-review-row{display:table-row;width:100%}.monaco-component.diff-review .diff-review-spacer{display:inline-block;vertical-align:middle;width:10px}.monaco-component.diff-review .diff-review-spacer>.codicon{font-size:9px!important}.monaco-component.diff-review .diff-review-actions{display:inline-block;position:absolute;right:10px;top:2px;z-index:100}.monaco-component.diff-review .diff-review-actions .action-label{height:16px;margin:2px 0;width:16px}.monaco-component.diff-review .revertButton{cursor:pointer}.monaco-editor .diff-hidden-lines-widget{width:100%}.monaco-editor .diff-hidden-lines{font-size:13px;height:0;line-height:14px;transform:translateY(-10px)}.monaco-editor .diff-hidden-lines .bottom.dragging,.monaco-editor .diff-hidden-lines .top.dragging,.monaco-editor .diff-hidden-lines:not(.dragging) .bottom:hover,.monaco-editor .diff-hidden-lines:not(.dragging) .top:hover{background-color:var(--vscode-focusBorder)}.monaco-editor .diff-hidden-lines .bottom,.monaco-editor .diff-hidden-lines .top{background-clip:padding-box;background-color:initial;border-bottom:2px solid #0000;border-top:4px solid #0000;height:4px;transition:background-color .1s ease-out}.monaco-editor .diff-hidden-lines .bottom.canMoveTop:not(.canMoveBottom),.monaco-editor .diff-hidden-lines .top.canMoveTop:not(.canMoveBottom),.monaco-editor.draggingUnchangedRegion.canMoveTop:not(.canMoveBottom) *{cursor:n-resize!important}.monaco-editor .diff-hidden-lines .bottom:not(.canMoveTop).canMoveBottom,.monaco-editor .diff-hidden-lines .top:not(.canMoveTop).canMoveBottom,.monaco-editor.draggingUnchangedRegion:not(.canMoveTop).canMoveBottom *{cursor:s-resize!important}.monaco-editor .diff-hidden-lines .bottom.canMoveTop.canMoveBottom,.monaco-editor .diff-hidden-lines .top.canMoveTop.canMoveBottom,.monaco-editor.draggingUnchangedRegion.canMoveTop.canMoveBottom *{cursor:ns-resize!important}.monaco-editor .diff-hidden-lines .top{transform:translateY(4px)}.monaco-editor .diff-hidden-lines .bottom{transform:translateY(-6px)}.monaco-editor .diff-unchanged-lines{background:var(--vscode-diffEditor-unchangedCodeBackground)}.monaco-editor .noModificationsOverlay{align-items:center;background:var(--vscode-editor-background);display:flex;justify-content:center;z-index:1}.monaco-editor .diff-hidden-lines .center{background:var(--vscode-diffEditor-unchangedRegionBackground);box-shadow:inset 0 -5px 5px -7px var(--vscode-diffEditor-unchangedRegionShadow),inset 0 5px 5px -7px var(--vscode-diffEditor-unchangedRegionShadow);color:var(--vscode-diffEditor-unchangedRegionForeground);display:block;height:24px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-editor .diff-hidden-lines .center span.codicon{vertical-align:middle}.monaco-editor .diff-hidden-lines .center a:hover .codicon{color:var(--vscode-editorLink-activeForeground)!important;cursor:pointer}.monaco-editor .diff-hidden-lines div.breadcrumb-item{cursor:pointer}.monaco-editor .diff-hidden-lines div.breadcrumb-item:hover{color:var(--vscode-editorLink-activeForeground)}.monaco-editor .movedModified,.monaco-editor .movedOriginal{border:2px solid var(--vscode-diffEditor-move-border)}.monaco-editor .movedModified.currentMove,.monaco-editor .movedOriginal.currentMove{border:2px solid var(--vscode-diffEditor-moveActive-border)}.monaco-diff-editor .moved-blocks-lines path.currentMove{stroke:var(--vscode-diffEditor-moveActive-border)}.monaco-diff-editor .moved-blocks-lines path{pointer-events:visiblestroke}.monaco-diff-editor .moved-blocks-lines .arrow{fill:var(--vscode-diffEditor-move-border)}.monaco-diff-editor .moved-blocks-lines .arrow.currentMove{fill:var(--vscode-diffEditor-moveActive-border)}.monaco-diff-editor .moved-blocks-lines .arrow-rectangle{fill:var(--vscode-editor-background)}.monaco-diff-editor .moved-blocks-lines{pointer-events:none;position:absolute}.monaco-diff-editor .moved-blocks-lines path{fill:none;stroke:var(--vscode-diffEditor-move-border);stroke-width:2}.monaco-editor .char-delete.diff-range-empty{border-left:3px solid var(--vscode-diffEditor-removedTextBackground);margin-left:-1px}.monaco-editor .char-insert.diff-range-empty{border-left:3px solid var(--vscode-diffEditor-insertedTextBackground)}.monaco-editor .fold-unchanged{cursor:pointer}.monaco-diff-editor .diff-moved-code-block{display:flex;justify-content:flex-end;margin-top:-4px}.monaco-diff-editor .diff-moved-code-block .action-bar .action-label.codicon{font-size:12px;height:12px;width:12px}.monaco-diff-editor .diffOverview{z-index:9}.monaco-diff-editor .diffOverview .diffViewport{z-index:10}.monaco-diff-editor.vs .diffOverview{background:#00000008}.monaco-diff-editor.vs-dark .diffOverview{background:#ffffff03}.monaco-scrollable-element.modified-in-monaco-diff-editor.vs .scrollbar,.monaco-scrollable-element.modified-in-monaco-diff-editor.vs-dark .scrollbar{background:#0000}.monaco-scrollable-element.modified-in-monaco-diff-editor.hc-black .scrollbar,.monaco-scrollable-element.modified-in-monaco-diff-editor.hc-light .scrollbar{background:none}.monaco-scrollable-element.modified-in-monaco-diff-editor .slider{z-index:10}.modified-in-monaco-diff-editor .slider.active{background:#ababab66}.modified-in-monaco-diff-editor.hc-black .slider.active,.modified-in-monaco-diff-editor.hc-light .slider.active{background:none}.monaco-diff-editor .delete-sign,.monaco-diff-editor .insert-sign,.monaco-editor .delete-sign,.monaco-editor .insert-sign{align-items:center;display:flex!important;font-size:11px!important;opacity:.7!important}.monaco-diff-editor.hc-black .delete-sign,.monaco-diff-editor.hc-black .insert-sign,.monaco-diff-editor.hc-light .delete-sign,.monaco-diff-editor.hc-light .insert-sign,.monaco-editor.hc-black .delete-sign,.monaco-editor.hc-black .insert-sign,.monaco-editor.hc-light .delete-sign,.monaco-editor.hc-light .insert-sign{opacity:1}.monaco-editor .inline-added-margin-view-zone,.monaco-editor .inline-deleted-margin-view-zone{text-align:right}.monaco-editor .arrow-revert-change{position:absolute;z-index:10}.monaco-editor .arrow-revert-change:hover{cursor:pointer}.monaco-editor .view-zones .view-lines .view-line span{display:inline-block}.monaco-editor .margin-view-zones .lightbulb-glyph:hover{cursor:pointer}.monaco-diff-editor .char-insert,.monaco-editor .char-insert{background-color:var(--vscode-diffEditor-insertedTextBackground)}.monaco-diff-editor .line-insert,.monaco-editor .line-insert{background-color:var(--vscode-diffEditor-insertedLineBackground,var(--vscode-diffEditor-insertedTextBackground))}.monaco-editor .char-insert,.monaco-editor .line-insert{border:1px solid var(--vscode-diffEditor-insertedTextBorder);box-sizing:border-box}.monaco-editor.hc-black .char-insert,.monaco-editor.hc-black .line-insert,.monaco-editor.hc-light .char-insert,.monaco-editor.hc-light .line-insert{border-style:dashed}.monaco-editor .char-delete,.monaco-editor .line-delete{border:1px solid var(--vscode-diffEditor-removedTextBorder);box-sizing:border-box}.monaco-editor.hc-black .char-delete,.monaco-editor.hc-black .line-delete,.monaco-editor.hc-light .char-delete,.monaco-editor.hc-light .line-delete{border-style:dashed}.monaco-diff-editor .gutter-insert,.monaco-editor .gutter-insert,.monaco-editor .inline-added-margin-view-zone{background-color:var(--vscode-diffEditorGutter-insertedLineBackground,var(--vscode-diffEditor-insertedLineBackground),var(--vscode-diffEditor-insertedTextBackground))}.monaco-diff-editor .char-delete,.monaco-editor .char-delete,.monaco-editor .inline-deleted-text{background-color:var(--vscode-diffEditor-removedTextBackground)}.monaco-editor .inline-deleted-text{text-decoration:line-through}.monaco-diff-editor .line-delete,.monaco-editor .line-delete{background-color:var(--vscode-diffEditor-removedLineBackground,var(--vscode-diffEditor-removedTextBackground))}.monaco-diff-editor .gutter-delete,.monaco-editor .gutter-delete,.monaco-editor .inline-deleted-margin-view-zone{background-color:var(--vscode-diffEditorGutter-removedLineBackground,var(--vscode-diffEditor-removedLineBackground),var(--vscode-diffEditor-removedTextBackground))}.monaco-diff-editor.side-by-side .editor.modified{border-left:1px solid var(--vscode-diffEditor-border);box-shadow:-6px 0 5px -5px var(--vscode-scrollbar-shadow)}.monaco-diff-editor.side-by-side .editor.original{border-right:1px solid var(--vscode-diffEditor-border);box-shadow:6px 0 5px -5px var(--vscode-scrollbar-shadow)}.monaco-diff-editor .diffViewport{background:var(--vscode-scrollbarSlider-background)}.monaco-diff-editor .diffViewport:hover{background:var(--vscode-scrollbarSlider-hoverBackground)}.monaco-diff-editor .diffViewport:active{background:var(--vscode-scrollbarSlider-activeBackground)}.monaco-editor .diagonal-fill{background-image:linear-gradient(-45deg,var(--vscode-diffEditor-diagonalFill) 12.5%,#0000 12.5%,#0000 50%,var(--vscode-diffEditor-diagonalFill) 50%,var(--vscode-diffEditor-diagonalFill) 62.5%,#0000 62.5%,#0000 100%);background-size:8px 8px}.monaco-diff-editor .gutter{flex-grow:0;flex-shrink:0;overflow:hidden;position:relative}.monaco-diff-editor .gutter>div{position:absolute}.monaco-diff-editor .gutter .gutterItem{opacity:0;transition:opacity .7s}.monaco-diff-editor .gutter .gutterItem.showAlways{opacity:1;transition:none}.monaco-diff-editor .gutter .gutterItem.noTransition{transition:none}.monaco-diff-editor .gutter:hover .gutterItem{opacity:1;transition:opacity .1s ease-in-out}.monaco-diff-editor .gutter .gutterItem .background{border-left:2px solid var(--vscode-menu-border);height:100%;left:50%;position:absolute;width:1px}.monaco-diff-editor .gutter .gutterItem .buttons{align-items:center;display:flex;justify-content:center;position:absolute;width:100%}.monaco-diff-editor .gutter .gutterItem .buttons .monaco-toolbar{height:fit-content}.monaco-diff-editor .gutter .gutterItem .buttons .monaco-toolbar .monaco-action-bar{line-height:1}.monaco-diff-editor .gutter .gutterItem .buttons .monaco-toolbar .monaco-action-bar .actions-container{background:var(--vscode-editorGutter-commentRangeForeground);border-radius:4px;width:fit-content}.monaco-diff-editor .gutter .gutterItem .buttons .monaco-toolbar .monaco-action-bar .actions-container .action-item:hover{background:var(--vscode-toolbar-hoverBackground)}.monaco-diff-editor .gutter .gutterItem .buttons .monaco-toolbar .monaco-action-bar .actions-container .action-item .action-label{padding:1px 2px}.monaco-diff-editor .diff-hidden-lines-compact{display:flex;height:11px}.monaco-diff-editor .diff-hidden-lines-compact .line-left,.monaco-diff-editor .diff-hidden-lines-compact .line-right{border-top:1px solid;border-color:var(--vscode-editorCodeLens-foreground);height:1px;margin:auto;opacity:.5;width:100%}.monaco-diff-editor .diff-hidden-lines-compact .line-left{width:20px}.monaco-diff-editor .diff-hidden-lines-compact .text{text-wrap:nowrap;color:var(--vscode-editorCodeLens-foreground);font-size:11px;line-height:11px;margin:0 4px}.monaco-editor .rendered-markdown kbd{background-color:var(--vscode-keybindingLabel-background);border-color:var(--vscode-keybindingLabel-border);border-bottom:1px var(--vscode-keybindingLabel-bottomBorder);border-left-width:1px;border-radius:3px;border-right-width:1px;border-style:solid;border-top-width:1px;box-shadow:inset 0 -1px 0 var(--vscode-widget-shadow);color:var(--vscode-keybindingLabel-foreground);padding:1px 3px;vertical-align:middle}.rendered-markdown li:has(input[type=checkbox]){list-style-type:none}.monaco-component.multiDiffEditor{background:var(--vscode-multiDiffEditor-background);height:100%;overflow-y:hidden;position:relative;width:100%}.monaco-component.multiDiffEditor>div{height:100%;left:0;position:absolute;top:0;width:100%}.monaco-component.multiDiffEditor>div.placeholder{display:grid;place-content:center;place-items:center;visibility:hidden}.monaco-component.multiDiffEditor>div.placeholder.visible{visibility:visible}.monaco-component.multiDiffEditor .active{--vscode-multiDiffEditor-border:var(--vscode-focusBorder)}.monaco-component.multiDiffEditor .multiDiffEntry{display:flex;flex:1 1;flex-direction:column;overflow:hidden}.monaco-component.multiDiffEditor .multiDiffEntry .collapse-button{cursor:pointer;margin:0 5px}.monaco-component.multiDiffEditor .multiDiffEntry .collapse-button a{display:block}.monaco-component.multiDiffEditor .multiDiffEntry .header{background:var(--vscode-editor-background);z-index:1000}.monaco-component.multiDiffEditor .multiDiffEntry .header:not(.collapsed) .header-content{border-bottom:1px solid var(--vscode-sideBarSectionHeader-border)}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content{align-items:center;background:var(--vscode-multiDiffEditor-headerBackground);border-top:1px solid var(--vscode-multiDiffEditor-border);color:var(--vscode-foreground);display:flex;margin:8px 0 0;padding:4px 5px}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content.shadow{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content .file-path{display:flex;flex:1 1;min-width:0}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content .file-path .title{font-size:14px;line-height:22px}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content .file-path .title.original{flex:1 1;min-width:0;text-overflow:ellipsis}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content .file-path .status{font-weight:600;line-height:22px;margin:0 10px;opacity:.75}.monaco-component.multiDiffEditor .multiDiffEntry .header .header-content .actions{padding:0 8px}.monaco-component.multiDiffEditor .multiDiffEntry .editorParent{border-bottom:1px solid var(--vscode-multiDiffEditor-border);display:flex;flex:1 1;flex-direction:column;overflow:hidden}.monaco-component.multiDiffEditor .multiDiffEntry .editorContainer{flex:1 1}.monaco-editor .selection-anchor{background-color:#007acc;width:2px!important}.monaco-editor .bracket-match{background-color:var(--vscode-editorBracketMatch-background);border:1px solid var(--vscode-editorBracketMatch-border);box-sizing:border-box}.monaco-editor .lightBulbWidget{align-items:center;display:flex;justify-content:center}.monaco-editor .lightBulbWidget:hover{cursor:pointer}.monaco-editor .lightBulbWidget.codicon-light-bulb,.monaco-editor .lightBulbWidget.codicon-lightbulb-sparkle{color:var(--vscode-editorLightBulb-foreground)}.monaco-editor .lightBulbWidget.codicon-lightbulb-autofix,.monaco-editor .lightBulbWidget.codicon-lightbulb-sparkle-autofix{color:var(--vscode-editorLightBulbAutoFix-foreground,var(--vscode-editorLightBulb-foreground))}.monaco-editor .lightBulbWidget.codicon-sparkle-filled{color:var(--vscode-editorLightBulbAi-foreground,var(--vscode-icon-foreground))}.monaco-editor .lightBulbWidget:before{position:relative;z-index:2}.monaco-editor .lightBulbWidget:after{content:"";display:block;height:100%;left:0;opacity:.3;position:absolute;top:0;width:100%;z-index:1}.monaco-editor .glyph-margin-widgets .cgmr[class*=codicon-gutter-lightbulb]{cursor:pointer;display:block}.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb,.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-sparkle{color:var(--vscode-editorLightBulb-foreground)}.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-aifix-auto-fix,.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-auto-fix{color:var(--vscode-editorLightBulbAutoFix-foreground,var(--vscode-editorLightBulb-foreground))}.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-sparkle-filled{color:var(--vscode-editorLightBulbAi-foreground,var(--vscode-icon-foreground))}.monaco-editor .codelens-decoration{font-feature-settings:var(--vscode-editorCodeLens-fontFeatureSettings);color:var(--vscode-editorCodeLens-foreground);display:inline-block;font-family:var(--vscode-editorCodeLens-fontFamily),var(--vscode-editorCodeLens-fontFamilyDefault);font-size:var(--vscode-editorCodeLens-fontSize);line-height:var(--vscode-editorCodeLens-lineHeight);overflow:hidden;padding-right:calc(var(--vscode-editorCodeLens-fontSize)*.5);text-overflow:ellipsis;white-space:nowrap}.monaco-editor .codelens-decoration>a,.monaco-editor .codelens-decoration>span{user-select:none;-webkit-user-select:none;vertical-align:sub;white-space:nowrap}.monaco-editor .codelens-decoration>a{text-decoration:none}.monaco-editor .codelens-decoration>a:hover{cursor:pointer}.monaco-editor .codelens-decoration>a:hover,.monaco-editor .codelens-decoration>a:hover .codicon{color:var(--vscode-editorLink-activeForeground)!important}.monaco-editor .codelens-decoration .codicon{color:currentColor!important;color:var(--vscode-editorCodeLens-foreground);font-size:var(--vscode-editorCodeLens-fontSize);line-height:var(--vscode-editorCodeLens-lineHeight);vertical-align:middle}.monaco-editor .codelens-decoration>a:hover .codicon:before{cursor:pointer}@keyframes fadein{0%{opacity:0;visibility:visible}to{opacity:1}}.monaco-editor .codelens-decoration.fadein{animation:fadein .1s linear}.colorpicker-widget{height:190px;user-select:none;-webkit-user-select:none}.colorpicker-color-decoration,.hc-light .colorpicker-color-decoration{border:.1em solid #000;box-sizing:border-box;cursor:pointer;display:inline-block;height:.8em;line-height:.8em;margin:.1em .2em 0;width:.8em}.hc-black .colorpicker-color-decoration,.vs-dark .colorpicker-color-decoration{border:.1em solid #eee}.colorpicker-header{background:url(data:image/png;base64,iVBORw0KGgoAAAANSUhEUgAAAAQAAAAECAYAAACp8Z5+AAAAAXNSR0IArs4c6QAAAARnQU1BAACxjwv8YQUAAAAJcEhZcwAADsMAAA7DAcdvqGQAAAAZdEVYdFNvZnR3YXJlAHBhaW50Lm5ldCA0LjAuMTZEaa/1AAAAHUlEQVQYV2PYvXu3JAi7uLiAMaYAjAGTQBPYLQkAa/0Zef3qRswAAAAASUVORK5CYII=);background-size:9px 9px;display:flex;height:24px;image-rendering:pixelated;position:relative}.colorpicker-header .picked-color{align-items:center;color:#fff;cursor:pointer;display:flex;flex:1 1;justify-content:center;line-height:24px;overflow:hidden;white-space:nowrap;width:240px}.colorpicker-header .picked-color .picked-color-presentation{margin-left:5px;margin-right:5px;white-space:nowrap}.colorpicker-header .picked-color .codicon{color:inherit;font-size:14px}.colorpicker-header .picked-color.light{color:#000}.colorpicker-header .original-color{cursor:pointer;width:74px;z-index:inherit}.standalone-colorpicker{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground)}.colorpicker-header.standalone-colorpicker{border-bottom:none}.colorpicker-header .close-button{background-color:var(--vscode-editorHoverWidget-background);border-left:1px solid var(--vscode-editorHoverWidget-border);cursor:pointer}.colorpicker-header .close-button-inner-div{height:100%;text-align:center;width:100%}.colorpicker-header .close-button-inner-div:hover{background-color:var(--vscode-toolbar-hoverBackground)}.colorpicker-header .close-icon{padding:3px}.colorpicker-body{display:flex;padding:8px;position:relative}.colorpicker-body .saturation-wrap{flex:1 1;height:150px;min-width:220px;overflow:hidden;position:relative}.colorpicker-body .saturation-box{height:150px;position:absolute}.colorpicker-body .saturation-selection{border:1px solid #fff;border-radius:100%;box-shadow:0 0 2px #000c;height:9px;margin:-5px 0 0 -5px;position:absolute;width:9px}.colorpicker-body .strip{height:150px;width:25px}.colorpicker-body .standalone-strip{height:122px;width:25px}.colorpicker-body .hue-strip{background:linear-gradient(180deg,red,#ff0 17%,#0f0 33%,#0ff 50%,#00f 67%,#f0f 83%,red);cursor:grab;margin-left:8px;position:relative}.colorpicker-body .opacity-strip{background:url(data:image/png;base64,iVBORw0KGgoAAAANSUhEUgAAAAQAAAAECAYAAACp8Z5+AAAAAXNSR0IArs4c6QAAAARnQU1BAACxjwv8YQUAAAAJcEhZcwAADsMAAA7DAcdvqGQAAAAZdEVYdFNvZnR3YXJlAHBhaW50Lm5ldCA0LjAuMTZEaa/1AAAAHUlEQVQYV2PYvXu3JAi7uLiAMaYAjAGTQBPYLQkAa/0Zef3qRswAAAAASUVORK5CYII=);background-size:9px 9px;cursor:grab;image-rendering:pixelated;margin-left:8px;position:relative}.colorpicker-body .strip.grabbing{cursor:grabbing}.colorpicker-body .slider{border:1px solid #ffffffb5;box-shadow:0 0 1px #000000d9;box-sizing:border-box;height:4px;left:-2px;position:absolute;top:0;width:calc(100% + 4px)}.colorpicker-body .strip .overlay{height:150px;pointer-events:none}.colorpicker-body .standalone-strip .standalone-overlay{height:122px;pointer-events:none}.standalone-colorpicker-body{border:1px solid #0000;border-bottom:1px solid var(--vscode-editorHoverWidget-border);display:block;overflow:hidden}.colorpicker-body .insert-button{background:var(--vscode-button-background);border:none;border-radius:2px;bottom:8px;color:var(--vscode-button-foreground);cursor:pointer;height:20px;padding:0;position:absolute;right:8px;width:58px}.colorpicker-body .insert-button:hover{background:var(--vscode-button-hoverBackground)}.monaco-editor.hc-light .dnd-target,.monaco-editor.vs .dnd-target{border-right:2px dotted #000;color:#fff}.monaco-editor.vs-dark .dnd-target{border-right:2px dotted #aeafad;color:#51504f}.monaco-editor.hc-black .dnd-target{border-right:2px dotted #fff;color:#000}.monaco-editor.hc-black.mac.mouse-default .view-lines,.monaco-editor.hc-light.mac.mouse-default .view-lines,.monaco-editor.mouse-default .view-lines,.monaco-editor.vs-dark.mac.mouse-default .view-lines{cursor:default}.monaco-editor.hc-black.mac.mouse-copy .view-lines,.monaco-editor.hc-light.mac.mouse-copy .view-lines,.monaco-editor.mouse-copy .view-lines,.monaco-editor.vs-dark.mac.mouse-copy .view-lines{cursor:copy}.post-edit-widget{background-color:var(--vscode-editorWidget-background);border:1px solid var(--vscode-widget-border,#0000);border-radius:4px;box-shadow:0 0 8px 2px var(--vscode-widget-shadow);overflow:hidden}.post-edit-widget .monaco-button{border:none;border-radius:0;padding:2px}.post-edit-widget .monaco-button:hover{background-color:var(--vscode-button-secondaryHoverBackground)!important}.post-edit-widget .monaco-button .codicon{margin:0}.monaco-editor .findOptionsWidget{border:2px solid var(--vscode-contrastBorder)}.monaco-editor .find-widget,.monaco-editor .findOptionsWidget{background-color:var(--vscode-editorWidget-background);box-shadow:0 0 8px 2px var(--vscode-widget-shadow);color:var(--vscode-editorWidget-foreground)}.monaco-editor .find-widget{border-bottom:1px solid var(--vscode-widget-border);border-bottom-left-radius:4px;border-bottom-right-radius:4px;border-left:1px solid var(--vscode-widget-border);border-right:1px solid var(--vscode-widget-border);box-sizing:border-box;height:33px;line-height:19px;overflow:hidden;padding:0 4px;position:absolute;transform:translateY(calc(-100% - 10px));transition:transform .2s linear;z-index:35}.monaco-workbench.reduce-motion .monaco-editor .find-widget{transition:transform 0ms linear}.monaco-editor .find-widget textarea{margin:0}.monaco-editor .find-widget.hiddenEditor{display:none}.monaco-editor .find-widget.replaceToggled>.replace-part{display:flex}.monaco-editor .find-widget.visible{transform:translateY(0)}.monaco-editor .find-widget .monaco-inputbox.synthetic-focus{outline:1px solid -webkit-focus-ring-color;outline-color:var(--vscode-focusBorder);outline-offset:-1px}.monaco-editor .find-widget .monaco-inputbox .input{background-color:initial;min-height:0}.monaco-editor .find-widget .monaco-findInput .input{font-size:13px}.monaco-editor .find-widget>.find-part,.monaco-editor .find-widget>.replace-part{display:flex;font-size:12px;margin:3px 25px 0 17px}.monaco-editor .find-widget>.find-part .monaco-inputbox,.monaco-editor .find-widget>.replace-part .monaco-inputbox{min-height:25px}.monaco-editor .find-widget>.replace-part .monaco-inputbox>.ibwrapper>.mirror{padding-right:22px}.monaco-editor .find-widget>.find-part .monaco-inputbox>.ibwrapper>.input,.monaco-editor .find-widget>.find-part .monaco-inputbox>.ibwrapper>.mirror,.monaco-editor .find-widget>.replace-part .monaco-inputbox>.ibwrapper>.input,.monaco-editor .find-widget>.replace-part .monaco-inputbox>.ibwrapper>.mirror{padding-bottom:2px;padding-top:2px}.monaco-editor .find-widget>.find-part .find-actions,.monaco-editor .find-widget>.replace-part .replace-actions{align-items:center;display:flex;height:25px}.monaco-editor .find-widget .monaco-findInput{display:flex;flex:1 1;vertical-align:middle}.monaco-editor .find-widget .monaco-findInput .monaco-scrollable-element{width:100%}.monaco-editor .find-widget .monaco-findInput .monaco-scrollable-element .scrollbar.vertical{opacity:0}.monaco-editor .find-widget .matchesCount{box-sizing:border-box;display:flex;flex:initial;height:25px;line-height:23px;margin:0 0 0 3px;padding:2px 0 0 2px;text-align:center;vertical-align:middle}.monaco-editor .find-widget .button{align-items:center;background-position:50%;background-repeat:no-repeat;border-radius:5px;cursor:pointer;display:flex;flex:initial;height:16px;justify-content:center;margin-left:3px;padding:3px;width:16px}.monaco-editor .find-widget .codicon-find-selection{border-radius:5px;height:22px;padding:3px;width:22px}.monaco-editor .find-widget .button.left{margin-left:0;margin-right:3px}.monaco-editor .find-widget .button.wide{padding:1px 6px;top:-1px;width:auto}.monaco-editor .find-widget .button.toggle{border-radius:0;box-sizing:border-box;height:100%;left:3px;position:absolute;top:0;width:18px}.monaco-editor .find-widget .button.toggle.disabled{display:none}.monaco-editor .find-widget .disabled{color:var(--vscode-disabledForeground);cursor:default}.monaco-editor .find-widget>.replace-part{display:none}.monaco-editor .find-widget>.replace-part>.monaco-findInput{display:flex;flex:auto;flex-grow:0;flex-shrink:0;position:relative;vertical-align:middle}.monaco-editor .find-widget>.replace-part>.monaco-findInput>.controls{position:absolute;right:2px;top:3px}.monaco-editor .find-widget.reduced-find-widget .matchesCount{display:none}.monaco-editor .find-widget.narrow-find-widget{max-width:257px!important}.monaco-editor .find-widget.collapsed-find-widget{max-width:170px!important}.monaco-editor .find-widget.collapsed-find-widget .button.next,.monaco-editor .find-widget.collapsed-find-widget .button.previous,.monaco-editor .find-widget.collapsed-find-widget .button.replace,.monaco-editor .find-widget.collapsed-find-widget .button.replace-all,.monaco-editor .find-widget.collapsed-find-widget>.find-part .monaco-findInput .controls{display:none}.monaco-editor .find-widget.no-results .matchesCount{color:var(--vscode-errorForeground)}.monaco-editor .findMatch{animation-duration:0;animation-name:inherit!important;background-color:var(--vscode-editor-findMatchHighlightBackground)}.monaco-editor .currentFindMatch{background-color:var(--vscode-editor-findMatchBackground);border:2px solid var(--vscode-editor-findMatchBorder);box-sizing:border-box;padding:1px}.monaco-editor .findScope{background-color:var(--vscode-editor-findRangeHighlightBackground)}.monaco-editor .find-widget .monaco-sash{background-color:var(--vscode-editorWidget-resizeBorder,var(--vscode-editorWidget-border));left:0!important}.monaco-editor.hc-black .find-widget .button:before{left:2px;position:relative;top:1px}.monaco-editor .find-widget .button:not(.disabled):hover,.monaco-editor .find-widget .codicon-find-selection:hover{background-color:var(--vscode-toolbar-hoverBackground)!important}.monaco-editor.findMatch{background-color:var(--vscode-editor-findMatchHighlightBackground)}.monaco-editor.currentFindMatch{background-color:var(--vscode-editor-findMatchBackground)}.monaco-editor.findScope{background-color:var(--vscode-editor-findRangeHighlightBackground)}.monaco-editor.findMatch{background-color:var(--vscode-editorWidget-background)}.monaco-editor .find-widget>.button.codicon-widget-close{position:absolute;right:4px;top:5px}.monaco-editor .margin-view-overlays .codicon-folding-collapsed,.monaco-editor .margin-view-overlays .codicon-folding-expanded,.monaco-editor .margin-view-overlays .codicon-folding-manual-collapsed,.monaco-editor .margin-view-overlays .codicon-folding-manual-expanded{align-items:center;cursor:pointer;display:flex;font-size:140%;justify-content:center;margin-left:2px;opacity:0;transition:opacity .5s}.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-collapsed,.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-expanded,.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-manual-collapsed,.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-manual-expanded{transition:initial}.monaco-editor .margin-view-overlays .codicon.alwaysShowFoldIcons,.monaco-editor .margin-view-overlays .codicon.codicon-folding-collapsed,.monaco-editor .margin-view-overlays .codicon.codicon-folding-manual-collapsed,.monaco-editor .margin-view-overlays:hover .codicon{opacity:1}.monaco-editor .inline-folded:after{color:var(--vscode-editor-foldPlaceholderForeground);content:"\22EF";cursor:pointer;display:inline;line-height:1em;margin:.1em .2em 0}.monaco-editor .folded-background{background-color:var(--vscode-editor-foldBackground)}.monaco-editor .cldr.codicon.codicon-folding-collapsed,.monaco-editor .cldr.codicon.codicon-folding-expanded,.monaco-editor .cldr.codicon.codicon-folding-manual-collapsed,.monaco-editor .cldr.codicon.codicon-folding-manual-expanded{color:var(--vscode-editorGutter-foldingControlForeground)!important}.monaco-editor .peekview-widget .head .peekview-title .severity-icon{display:inline-block;margin-right:4px;vertical-align:text-top}.monaco-editor .marker-widget{text-overflow:ellipsis;white-space:nowrap}.monaco-editor .marker-widget>.stale{font-style:italic;opacity:.6}.monaco-editor .marker-widget .title{display:inline-block;padding-right:5px}.monaco-editor .marker-widget .descriptioncontainer{padding:8px 12px 0 20px;position:absolute;user-select:text;-webkit-user-select:text;white-space:pre}.monaco-editor .marker-widget .descriptioncontainer .message{display:flex;flex-direction:column}.monaco-editor .marker-widget .descriptioncontainer .message .details{padding-left:6px}.monaco-editor .marker-widget .descriptioncontainer .message .source,.monaco-editor .marker-widget .descriptioncontainer .message span.code{opacity:.6}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link{color:inherit;opacity:.6}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link:before{content:"("}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link:after{content:")"}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link>span{border-bottom:1px solid #0000;color:var(--vscode-textLink-activeForeground);text-decoration:underline;text-underline-position:under}.monaco-editor .marker-widget .descriptioncontainer .filename{color:var(--vscode-textLink-activeForeground);cursor:pointer}.monaco-editor .goto-definition-link{color:var(--vscode-editorLink-activeForeground)!important;cursor:pointer;text-decoration:underline}.monaco-editor .zone-widget .zone-widget-container.reference-zone-widget{border-bottom-width:1px;border-top-width:1px}.monaco-editor .reference-zone-widget .inline{display:inline-block;vertical-align:top}.monaco-editor .reference-zone-widget .messages{height:100%;padding:3em 0;text-align:center;width:100%}.monaco-editor .reference-zone-widget .ref-tree{background-color:var(--vscode-peekViewResult-background);color:var(--vscode-peekViewResult-lineForeground);line-height:23px}.monaco-editor .reference-zone-widget .ref-tree .reference{overflow:hidden;text-overflow:ellipsis}.monaco-editor .reference-zone-widget .ref-tree .reference-file{color:var(--vscode-peekViewResult-fileForeground);display:inline-flex;height:100%;width:100%}.monaco-editor .reference-zone-widget .ref-tree .monaco-list:focus .selected .reference-file{color:inherit!important}.monaco-editor .reference-zone-widget .ref-tree .monaco-list:focus .monaco-list-rows>.monaco-list-row.selected:not(.highlighted){background-color:var(--vscode-peekViewResult-selectionBackground);color:var(--vscode-peekViewResult-selectionForeground)!important}.monaco-editor .reference-zone-widget .ref-tree .reference-file .count{margin-left:auto;margin-right:12px}.monaco-editor .reference-zone-widget .ref-tree .referenceMatch .highlight{background-color:var(--vscode-peekViewResult-matchHighlightBackground)}.monaco-editor .reference-zone-widget .preview .reference-decoration{background-color:var(--vscode-peekViewEditor-matchHighlightBackground);border:2px solid var(--vscode-peekViewEditor-matchHighlightBorder);box-sizing:border-box}.monaco-editor .reference-zone-widget .preview .monaco-editor .inputarea.ime-input,.monaco-editor .reference-zone-widget .preview .monaco-editor .monaco-editor-background{background-color:var(--vscode-peekViewEditor-background)}.monaco-editor .reference-zone-widget .preview .monaco-editor .margin{background-color:var(--vscode-peekViewEditorGutter-background)}.monaco-editor.hc-black .reference-zone-widget .ref-tree .reference-file,.monaco-editor.hc-light .reference-zone-widget .ref-tree .reference-file{font-weight:700}.monaco-editor.hc-black .reference-zone-widget .ref-tree .referenceMatch .highlight,.monaco-editor.hc-light .reference-zone-widget .ref-tree .referenceMatch .highlight{border:1px dotted var(--vscode-contrastActiveBorder,#0000);box-sizing:border-box}.monaco-editor .hoverHighlight{background-color:var(--vscode-editor-hoverHighlightBackground)}.monaco-editor .monaco-hover-content{box-sizing:border-box;padding-bottom:2px;padding-right:2px}.monaco-editor .monaco-hover{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);border-radius:3px;color:var(--vscode-editorHoverWidget-foreground)}.monaco-editor .monaco-hover a{color:var(--vscode-textLink-foreground)}.monaco-editor .monaco-hover a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor .monaco-hover .hover-row{display:flex}.monaco-editor .monaco-hover .hover-row .hover-row-contents{display:flex;flex-direction:column;min-width:0}.monaco-editor .monaco-hover .hover-row .verbosity-actions{border-right:1px solid var(--vscode-editorHoverWidget-border);display:flex;flex-direction:column;justify-content:end;padding-left:5px;padding-right:5px}.monaco-editor .monaco-hover .hover-row .verbosity-actions .codicon{cursor:pointer;font-size:11px}.monaco-editor .monaco-hover .hover-row .verbosity-actions .codicon.enabled{color:var(--vscode-textLink-foreground)}.monaco-editor .monaco-hover .hover-row .verbosity-actions .codicon.disabled{opacity:.6}.monaco-editor .monaco-hover .hover-row .actions{background-color:var(--vscode-editorHoverWidget-statusBarBackground)}.monaco-editor .monaco-hover code{background-color:var(--vscode-textCodeBlock-background)}.monaco-editor.vs .valueSetReplacement{outline:solid 2px var(--vscode-editorBracketMatch-border)}.monaco-editor .inlineSuggestionsHints.withBorder{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);z-index:39}.monaco-editor .inlineSuggestionsHints a,.monaco-editor .inlineSuggestionsHints a:hover{color:var(--vscode-foreground)}.monaco-editor .inlineSuggestionsHints .keybinding{display:flex;margin-left:4px;opacity:.6}.monaco-editor .inlineSuggestionsHints .keybinding .monaco-keybinding-key{font-size:8px;padding:2px 3px}.monaco-editor .inlineSuggestionsHints .availableSuggestionCount a{display:flex;justify-content:center;min-width:19px}.monaco-editor .inlineSuggestionStatusBarItemLabel{margin-right:2px}.monaco-editor .suggest-preview-additional-widget{white-space:nowrap}.monaco-editor .suggest-preview-additional-widget .content-spacer{color:#0000;white-space:pre}.monaco-editor .suggest-preview-additional-widget .button{cursor:pointer;display:inline-block;text-decoration:underline;text-underline-position:under}.monaco-editor .ghost-text-hidden{font-size:0;opacity:0}.monaco-editor .ghost-text-decoration,.monaco-editor .suggest-preview-text .ghost-text{font-style:italic}.monaco-editor .ghost-text-decoration,.monaco-editor .ghost-text-decoration-preview,.monaco-editor .suggest-preview-text .ghost-text{background-color:var(--vscode-editorGhostText-background);border:1px solid var(--vscode-editorGhostText-border);color:var(--vscode-editorGhostText-foreground)!important}.monaco-editor .inline-edit-remove{background-color:var(--vscode-editorGhostText-background);font-style:italic}.monaco-editor .inline-edit-hidden{font-size:0;opacity:0}.monaco-editor .inline-edit-decoration,.monaco-editor .suggest-preview-text .inline-edit{font-style:italic}.monaco-editor .inline-completion-text-to-replace{text-decoration:underline;text-underline-position:under}.monaco-editor .inline-edit-decoration,.monaco-editor .inline-edit-decoration-preview,.monaco-editor .suggest-preview-text .inline-edit{background-color:var(--vscode-editorGhostText-background);border:1px solid var(--vscode-editorGhostText-border);color:var(--vscode-editorGhostText-foreground)!important}.monaco-editor .inlineEditHints.withBorder{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);z-index:39}.monaco-editor .inlineEditHints a,.monaco-editor .inlineEditHints a:hover{color:var(--vscode-foreground)}.monaco-editor .inlineEditHints .keybinding{display:flex;margin-left:4px;opacity:.6}.monaco-editor .inlineEditHints .keybinding .monaco-keybinding-key{font-size:8px;padding:2px 3px}.monaco-editor .inlineEditStatusBarItemLabel{margin-right:2px}.monaco-editor .inlineEditSideBySide{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);white-space:pre;z-index:39}.monaco-editor div.inline-edits-widget{--widget-color:var(--vscode-notifications-background)}.monaco-editor div.inline-edits-widget .promptEditor .monaco-editor{--vscode-editor-placeholder-foreground:var(--vscode-editorGhostText-foreground)}.monaco-editor div.inline-edits-widget .promptEditor,.monaco-editor div.inline-edits-widget .toolbar{opacity:0;transition:opacity .2s ease-in-out}.monaco-editor div.inline-edits-widget.focused .promptEditor,.monaco-editor div.inline-edits-widget.focused .toolbar,.monaco-editor div.inline-edits-widget:hover .promptEditor,.monaco-editor div.inline-edits-widget:hover .toolbar{opacity:1}.monaco-editor div.inline-edits-widget .preview .monaco-editor{--vscode-editor-background:var(--widget-color)}.monaco-editor div.inline-edits-widget .preview .monaco-editor .mtk1{color:var(--vscode-editorGhostText-foreground)}.monaco-editor div.inline-edits-widget .preview .monaco-editor .current-line-margin,.monaco-editor div.inline-edits-widget .preview .monaco-editor .view-overlays .current-line-exact{border:none}.monaco-editor div.inline-edits-widget svg .gradient-start{stop-color:var(--vscode-editor-background)}.monaco-editor div.inline-edits-widget svg .gradient-stop{stop-color:var(--widget-color)}.inline-editor-progress-decoration{display:inline-block;height:1em;width:1em}.inline-progress-widget{align-items:center;display:flex!important;justify-content:center}.inline-progress-widget .icon{font-size:80%!important}.inline-progress-widget:hover .icon{animation:none;font-size:90%!important}.inline-progress-widget:hover .icon:before{content:var(--vscode-icon-x-content);font-family:var(--vscode-icon-x-font-family)}.monaco-editor .linked-editing-decoration{background-color:var(--vscode-editor-linkedEditingBackground);min-width:1px}.monaco-editor .detected-link,.monaco-editor .detected-link-active{text-decoration:underline;text-underline-position:under}.monaco-editor .detected-link-active{color:var(--vscode-editorLink-activeForeground)!important;cursor:pointer}.monaco-editor .monaco-editor-overlaymessage{padding-bottom:8px;z-index:10000}.monaco-editor .monaco-editor-overlaymessage.below{padding-bottom:0;padding-top:8px;z-index:10000}@keyframes fadeIn{0%{opacity:0}to{opacity:1}}.monaco-editor .monaco-editor-overlaymessage.fadeIn{animation:fadeIn .15s ease-out}@keyframes fadeOut{0%{opacity:1}to{opacity:0}}.monaco-editor .monaco-editor-overlaymessage.fadeOut{animation:fadeOut .1s ease-out}.monaco-editor .monaco-editor-overlaymessage .message{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-inputValidation-infoBorder);border-radius:3px;color:var(--vscode-editorHoverWidget-foreground);padding:2px 4px}.monaco-editor .monaco-editor-overlaymessage .message p{margin-block:0}.monaco-editor .monaco-editor-overlaymessage .message a{color:var(--vscode-textLink-foreground)}.monaco-editor .monaco-editor-overlaymessage .message a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor.hc-black .monaco-editor-overlaymessage .message,.monaco-editor.hc-light .monaco-editor-overlaymessage .message{border-width:2px}.monaco-editor .monaco-editor-overlaymessage .anchor{border:8px solid #0000;height:0!important;left:2px;position:absolute;width:0!important;z-index:1000}.monaco-editor .monaco-editor-overlaymessage .anchor.top{border-bottom-color:var(--vscode-inputValidation-infoBorder)}.monaco-editor .monaco-editor-overlaymessage .anchor.below{border-top-color:var(--vscode-inputValidation-infoBorder)}.monaco-editor .monaco-editor-overlaymessage.below .anchor.below,.monaco-editor .monaco-editor-overlaymessage:not(.below) .anchor.top{display:none}.monaco-editor .monaco-editor-overlaymessage.below .anchor.top{display:inherit;top:-8px}.monaco-editor .parameter-hints-widget{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);cursor:default;display:flex;flex-direction:column;line-height:1.5em;z-index:39}.hc-black .monaco-editor .parameter-hints-widget,.hc-light .monaco-editor .parameter-hints-widget{border-width:2px}.monaco-editor .parameter-hints-widget>.phwrapper{display:flex;flex-direction:row;max-width:440px}.monaco-editor .parameter-hints-widget.multiple{min-height:3.3em;padding:0}.monaco-editor .parameter-hints-widget.multiple .body:before{border-left:1px solid var(--vscode-editorHoverWidget-border);content:"";display:block;height:100%;opacity:.5;position:absolute}.monaco-editor .parameter-hints-widget p,.monaco-editor .parameter-hints-widget ul{margin:8px 0}.monaco-editor .parameter-hints-widget .body,.monaco-editor .parameter-hints-widget .monaco-scrollable-element{display:flex;flex:1 1;flex-direction:column;min-height:100%}.monaco-editor .parameter-hints-widget .signature{padding:4px 5px;position:relative}.monaco-editor .parameter-hints-widget .signature.has-docs:after{border-bottom:1px solid var(--vscode-editorHoverWidget-border);content:"";display:block;left:0;opacity:.5;padding-top:4px;position:absolute;width:100%}.monaco-editor .parameter-hints-widget .code{font-family:var(--vscode-parameterHintsWidget-editorFontFamily),var(--vscode-parameterHintsWidget-editorFontFamilyDefault)}.monaco-editor .parameter-hints-widget .docs{padding:0 10px 0 5px;white-space:pre-wrap}.monaco-editor .parameter-hints-widget .docs.empty{display:none}.monaco-editor .parameter-hints-widget .docs a{color:var(--vscode-textLink-foreground)}.monaco-editor .parameter-hints-widget .docs a:hover{color:var(--vscode-textLink-activeForeground);cursor:pointer}.monaco-editor .parameter-hints-widget .docs .markdown-docs{white-space:normal}.monaco-editor .parameter-hints-widget .docs code{background-color:var(--vscode-textCodeBlock-background);border-radius:3px;font-family:var(--monaco-monospace-font);padding:0 .4em}.monaco-editor .parameter-hints-widget .docs .code,.monaco-editor .parameter-hints-widget .docs .monaco-tokenized-source{white-space:pre-wrap}.monaco-editor .parameter-hints-widget .controls{align-items:center;display:none;flex-direction:column;justify-content:flex-end;min-width:22px}.monaco-editor .parameter-hints-widget.multiple .controls{display:flex;padding:0 2px}.monaco-editor .parameter-hints-widget.multiple .button{background-repeat:no-repeat;cursor:pointer;height:16px;width:16px}.monaco-editor .parameter-hints-widget .button.previous{bottom:24px}.monaco-editor .parameter-hints-widget .overloads{font-family:var(--monaco-monospace-font);height:12px;line-height:12px;text-align:center}.monaco-editor .parameter-hints-widget .signature .parameter.active{color:var(--vscode-editorHoverWidget-highlightForeground);font-weight:700}.monaco-editor .parameter-hints-widget .documentation-parameter>.parameter{font-weight:700;margin-right:.5em}.monaco-editor .peekview-widget .head{box-sizing:border-box;display:flex;flex-wrap:nowrap;justify-content:space-between}.monaco-editor .peekview-widget .head .peekview-title{align-items:baseline;display:flex;font-size:13px;margin-left:20px;min-width:0;overflow:hidden;text-overflow:ellipsis}.monaco-editor .peekview-widget .head .peekview-title.clickable{cursor:pointer}.monaco-editor .peekview-widget .head .peekview-title .dirname:not(:empty){font-size:.9em;margin-left:.5em}.monaco-editor .peekview-widget .head .peekview-title .dirname,.monaco-editor .peekview-widget .head .peekview-title .filename,.monaco-editor .peekview-widget .head .peekview-title .meta{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-editor .peekview-widget .head .peekview-title .meta:not(:empty):before{content:"-";padding:0 .3em}.monaco-editor .peekview-widget .head .peekview-actions{flex:1 1;padding-right:2px;text-align:right}.monaco-editor .peekview-widget .head .peekview-actions>.monaco-action-bar{display:inline-block}.monaco-editor .peekview-widget .head .peekview-actions>.monaco-action-bar,.monaco-editor .peekview-widget .head .peekview-actions>.monaco-action-bar>.actions-container{height:100%}.monaco-editor .peekview-widget>.body{border-top:1px solid;position:relative}.monaco-editor .peekview-widget .head .peekview-title .codicon{align-self:center;margin-right:4px}.monaco-editor .peekview-widget .monaco-list .monaco-list-row.focused .codicon{color:inherit!important}.monaco-editor{--vscode-editor-placeholder-foreground:var(--vscode-editorGhostText-foreground)}.monaco-editor .editorPlaceholder{text-wrap:nowrap;color:var(--vscode-editor-placeholder-foreground);overflow:hidden;pointer-events:none;position:absolute;text-overflow:ellipsis;top:0}.monaco-editor .rename-box{border-radius:4px;color:inherit;z-index:100}.monaco-editor .rename-box.preview{padding:4px 4px 0}.monaco-editor .rename-box .rename-input-with-button{border-radius:2px;padding:3px;width:calc(100% - 8px)}.monaco-editor .rename-box .rename-input{padding:0;width:calc(100% - 8px)}.monaco-editor .rename-box .rename-input:focus{outline:none}.monaco-editor .rename-box .rename-suggestions-button{align-items:center;background-color:initial;border:none;border-radius:5px;cursor:pointer;display:flex;padding:3px}.monaco-editor .rename-box .rename-suggestions-button:hover{background-color:var(--vscode-toolbar-hoverBackground)}.monaco-editor .rename-box .rename-candidate-list-container .monaco-list-row{border-radius:2px}.monaco-editor .rename-box .rename-label{display:none;opacity:.8}.monaco-editor .rename-box.preview .rename-label{display:inherit}.monaco-editor .snippet-placeholder{background-color:var(--vscode-editor-snippetTabstopHighlightBackground,#0000);min-width:2px;outline-color:var(--vscode-editor-snippetTabstopHighlightBorder,#0000);outline-style:solid;outline-width:1px}.monaco-editor .finish-snippet-placeholder{background-color:var(--vscode-editor-snippetFinalTabstopHighlightBackground,#0000);outline-color:var(--vscode-editor-snippetFinalTabstopHighlightBorder,#0000);outline-style:solid;outline-width:1px}.monaco-editor .sticky-widget{overflow:hidden}.monaco-editor .sticky-widget-line-numbers{background-color:inherit;float:left}.monaco-editor .sticky-widget-lines-scrollable{background-color:inherit;display:inline-block;overflow:hidden;position:absolute;width:var(--vscode-editorStickyScroll-scrollableWidth)}.monaco-editor .sticky-widget-lines{background-color:inherit;position:absolute}.monaco-editor .sticky-line-content,.monaco-editor .sticky-line-number{background-color:inherit;color:var(--vscode-editorLineNumber-foreground);display:inline-block;position:absolute;white-space:nowrap}.monaco-editor .sticky-line-number .codicon-folding-collapsed,.monaco-editor .sticky-line-number .codicon-folding-expanded{float:right;transition:var(--vscode-editorStickyScroll-foldingOpacityTransition)}.monaco-editor .sticky-line-content{background-color:inherit;white-space:nowrap;width:var(--vscode-editorStickyScroll-scrollableWidth)}.monaco-editor .sticky-line-number-inner{display:inline-block;text-align:right}.monaco-editor .sticky-widget{border-bottom:1px solid var(--vscode-editorStickyScroll-border)}.monaco-editor .sticky-line-content:hover{background-color:var(--vscode-editorStickyScrollHover-background);cursor:pointer}.monaco-editor .sticky-widget{background-color:var(--vscode-editorStickyScroll-background);box-shadow:var(--vscode-editorStickyScroll-shadow) 0 4px 2px -2px;right:auto!important;width:100%;z-index:4}.monaco-editor .sticky-widget.peek{background-color:var(--vscode-peekViewEditorStickyScroll-background)}.monaco-editor .suggest-widget{border-radius:3px;display:flex;flex-direction:column;width:430px;z-index:40}.monaco-editor .suggest-widget.message{align-items:center;flex-direction:row}.monaco-editor .suggest-details,.monaco-editor .suggest-widget{background-color:var(--vscode-editorSuggestWidget-background);border-color:var(--vscode-editorSuggestWidget-border);border-style:solid;border-width:1px;flex:0 1 auto;width:100%}.monaco-editor.hc-black .suggest-details,.monaco-editor.hc-black .suggest-widget,.monaco-editor.hc-light .suggest-details,.monaco-editor.hc-light .suggest-widget{border-width:2px}.monaco-editor .suggest-widget .suggest-status-bar{border-top:1px solid var(--vscode-editorSuggestWidget-border);box-sizing:border-box;display:none;flex-flow:row nowrap;font-size:80%;justify-content:space-between;overflow:hidden;padding:0 4px;width:100%}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar{display:flex}.monaco-editor .suggest-widget .suggest-status-bar .left{padding-right:8px}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar .action-label{color:var(--vscode-editorSuggestWidgetStatus-foreground)}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar .action-item:not(:last-of-type) .action-label{margin-right:0}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar .action-item:not(:last-of-type) .action-label:after{content:", ";margin-right:.3em}.monaco-editor .suggest-widget.with-status-bar .monaco-list .monaco-list-row.focused.string-label>.contents>.main>.right>.readMore,.monaco-editor .suggest-widget.with-status-bar .monaco-list .monaco-list-row>.contents>.main>.right>.readMore{display:none}.monaco-editor .suggest-widget.with-status-bar:not(.docs-side) .monaco-list .monaco-list-row:hover>.contents>.main>.right.can-expand-details>.details-label{width:100%}.monaco-editor .suggest-widget>.message{padding-left:22px}.monaco-editor .suggest-widget>.tree{height:100%;width:100%}.monaco-editor .suggest-widget .monaco-list{user-select:none;-webkit-user-select:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row{background-position:2px 2px;background-repeat:no-repeat;-mox-box-sizing:border-box;box-sizing:border-box;cursor:pointer;display:flex;padding-right:10px;touch-action:none;white-space:nowrap}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused{color:var(--vscode-editorSuggestWidget-selectedForeground)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused .codicon{color:var(--vscode-editorSuggestWidget-selectedIconForeground)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents{flex:1 1;height:100%;overflow:hidden;padding-left:2px}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main{display:flex;justify-content:space-between;overflow:hidden;text-overflow:ellipsis;white-space:pre}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left,.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right{display:flex}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.focused)>.contents>.main .monaco-icon-label{color:var(--vscode-editorSuggestWidget-foreground)}.monaco-editor .suggest-widget:not(.frozen) .monaco-highlighted-label .highlight{font-weight:700}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main .monaco-highlighted-label .highlight{color:var(--vscode-editorSuggestWidget-highlightForeground)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused>.contents>.main .monaco-highlighted-label .highlight{color:var(--vscode-editorSuggestWidget-focusHighlightForeground)}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.codicon-close,.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.readMore:before{color:inherit;cursor:pointer;font-size:14px;opacity:1}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.codicon-close{position:absolute;right:2px;top:6px}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.codicon-close:hover,.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.readMore:hover{opacity:1}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label{opacity:.7}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left>.signature-label{opacity:.6;overflow:hidden;text-overflow:ellipsis}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left>.qualifier-label{align-self:center;font-size:85%;line-height:normal;margin-left:12px;opacity:.4;overflow:hidden;text-overflow:ellipsis}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label{font-size:85%;margin-left:1.1em;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label>.monaco-tokenized-source{display:inline}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.string-label)>.contents>.main>.right>.details-label,.monaco-editor .suggest-widget.docs-side .monaco-list .monaco-list-row.focused:not(.string-label)>.contents>.main>.right>.details-label,.monaco-editor .suggest-widget:not(.shows-details) .monaco-list .monaco-list-row.focused>.contents>.main>.right>.details-label{display:inline}.monaco-editor .suggest-widget:not(.docs-side) .monaco-list .monaco-list-row.focused:hover>.contents>.main>.right.can-expand-details>.details-label{width:calc(100% - 26px)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left{flex-grow:1;flex-shrink:1;overflow:hidden}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left>.monaco-icon-label{flex-shrink:0}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.string-label)>.contents>.main>.left>.monaco-icon-label{max-width:100%}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.string-label>.contents>.main>.left>.monaco-icon-label{flex-shrink:1}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right{flex-shrink:4;max-width:70%;overflow:hidden}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.readMore{display:inline-block;height:18px;position:absolute;right:10px;visibility:hidden;width:18px}.monaco-editor .suggest-widget.docs-side .monaco-list .monaco-list-row>.contents>.main>.right>.readMore{display:none!important}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.string-label>.contents>.main>.right>.readMore{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused.string-label>.contents>.main>.right>.readMore{display:inline-block}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused:hover>.contents>.main>.right>.readMore{visibility:visible}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .monaco-icon-label.deprecated{opacity:.66;text-decoration:unset}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .monaco-icon-label.deprecated>.monaco-icon-label-container>.monaco-icon-name-container{text-decoration:line-through}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .monaco-icon-label:before{height:100%}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .icon{background-position:50%;background-repeat:no-repeat;background-size:80%;display:block;height:16px;margin-left:2px;width:16px}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .icon.hide{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .suggest-icon{align-items:center;display:flex;margin-right:4px}.monaco-editor .suggest-widget.no-icons .monaco-list .monaco-list-row .icon,.monaco-editor .suggest-widget.no-icons .monaco-list .monaco-list-row .suggest-icon:before{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .icon.customcolor .colorspan{border:.1em solid #000;display:inline-block;height:.7em;margin:0 0 0 .3em;width:.7em}.monaco-editor .suggest-details-container{z-index:41}.monaco-editor .suggest-details{color:var(--vscode-editorSuggestWidget-foreground);cursor:default;display:flex;flex-direction:column}.monaco-editor .suggest-details.focused{border-color:var(--vscode-focusBorder)}.monaco-editor .suggest-details a{color:var(--vscode-textLink-foreground)}.monaco-editor .suggest-details a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor .suggest-details code{background-color:var(--vscode-textCodeBlock-background)}.monaco-editor .suggest-details.no-docs{display:none}.monaco-editor .suggest-details>.monaco-scrollable-element{flex:1 1}.monaco-editor .suggest-details>.monaco-scrollable-element>.body{box-sizing:border-box;height:100%;width:100%}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.type{flex:2 1;margin:0 24px 0 0;opacity:.7;overflow:hidden;padding:4px 0 12px 5px;text-overflow:ellipsis;white-space:pre}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.type.auto-wrap{white-space:normal;word-break:break-all}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs{margin:0;padding:4px 5px;white-space:pre-wrap}.monaco-editor .suggest-details.no-type>.monaco-scrollable-element>.body>.docs{margin-right:24px;overflow:hidden}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs{min-height:calc(1rem + 8px);padding:0;white-space:normal}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>div,.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>span:not(:empty){padding:4px 5px}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>div>p:first-child{margin-top:0}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>div>p:last-child{margin-bottom:0}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs .monaco-tokenized-source{white-space:pre}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs .code{word-wrap:break-word;white-space:pre-wrap}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs .codicon{vertical-align:sub}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>p:empty{display:none}.monaco-editor .suggest-details code{border-radius:3px;padding:0 .4em}.monaco-editor .suggest-details ol,.monaco-editor .suggest-details ul{padding-left:20px}.monaco-editor .suggest-details p code{font-family:var(--monaco-monospace-font)}.monaco-editor .codicon.codicon-symbol-array,.monaco-workbench .codicon.codicon-symbol-array{color:var(--vscode-symbolIcon-arrayForeground)}.monaco-editor .codicon.codicon-symbol-boolean,.monaco-workbench .codicon.codicon-symbol-boolean{color:var(--vscode-symbolIcon-booleanForeground)}.monaco-editor .codicon.codicon-symbol-class,.monaco-workbench .codicon.codicon-symbol-class{color:var(--vscode-symbolIcon-classForeground)}.monaco-editor .codicon.codicon-symbol-method,.monaco-workbench .codicon.codicon-symbol-method{color:var(--vscode-symbolIcon-methodForeground)}.monaco-editor .codicon.codicon-symbol-color,.monaco-workbench .codicon.codicon-symbol-color{color:var(--vscode-symbolIcon-colorForeground)}.monaco-editor .codicon.codicon-symbol-constant,.monaco-workbench .codicon.codicon-symbol-constant{color:var(--vscode-symbolIcon-constantForeground)}.monaco-editor .codicon.codicon-symbol-constructor,.monaco-workbench .codicon.codicon-symbol-constructor{color:var(--vscode-symbolIcon-constructorForeground)}.monaco-editor .codicon.codicon-symbol-enum,.monaco-editor .codicon.codicon-symbol-value,.monaco-workbench .codicon.codicon-symbol-enum,.monaco-workbench .codicon.codicon-symbol-value{color:var(--vscode-symbolIcon-enumeratorForeground)}.monaco-editor .codicon.codicon-symbol-enum-member,.monaco-workbench .codicon.codicon-symbol-enum-member{color:var(--vscode-symbolIcon-enumeratorMemberForeground)}.monaco-editor .codicon.codicon-symbol-event,.monaco-workbench .codicon.codicon-symbol-event{color:var(--vscode-symbolIcon-eventForeground)}.monaco-editor .codicon.codicon-symbol-field,.monaco-workbench .codicon.codicon-symbol-field{color:var(--vscode-symbolIcon-fieldForeground)}.monaco-editor .codicon.codicon-symbol-file,.monaco-workbench .codicon.codicon-symbol-file{color:var(--vscode-symbolIcon-fileForeground)}.monaco-editor .codicon.codicon-symbol-folder,.monaco-workbench .codicon.codicon-symbol-folder{color:var(--vscode-symbolIcon-folderForeground)}.monaco-editor .codicon.codicon-symbol-function,.monaco-workbench .codicon.codicon-symbol-function{color:var(--vscode-symbolIcon-functionForeground)}.monaco-editor .codicon.codicon-symbol-interface,.monaco-workbench .codicon.codicon-symbol-interface{color:var(--vscode-symbolIcon-interfaceForeground)}.monaco-editor .codicon.codicon-symbol-key,.monaco-workbench .codicon.codicon-symbol-key{color:var(--vscode-symbolIcon-keyForeground)}.monaco-editor .codicon.codicon-symbol-keyword,.monaco-workbench .codicon.codicon-symbol-keyword{color:var(--vscode-symbolIcon-keywordForeground)}.monaco-editor .codicon.codicon-symbol-module,.monaco-workbench .codicon.codicon-symbol-module{color:var(--vscode-symbolIcon-moduleForeground)}.monaco-editor .codicon.codicon-symbol-namespace,.monaco-workbench .codicon.codicon-symbol-namespace{color:var(--vscode-symbolIcon-namespaceForeground)}.monaco-editor .codicon.codicon-symbol-null,.monaco-workbench .codicon.codicon-symbol-null{color:var(--vscode-symbolIcon-nullForeground)}.monaco-editor .codicon.codicon-symbol-number,.monaco-workbench .codicon.codicon-symbol-number{color:var(--vscode-symbolIcon-numberForeground)}.monaco-editor .codicon.codicon-symbol-object,.monaco-workbench .codicon.codicon-symbol-object{color:var(--vscode-symbolIcon-objectForeground)}.monaco-editor .codicon.codicon-symbol-operator,.monaco-workbench .codicon.codicon-symbol-operator{color:var(--vscode-symbolIcon-operatorForeground)}.monaco-editor .codicon.codicon-symbol-package,.monaco-workbench .codicon.codicon-symbol-package{color:var(--vscode-symbolIcon-packageForeground)}.monaco-editor .codicon.codicon-symbol-property,.monaco-workbench .codicon.codicon-symbol-property{color:var(--vscode-symbolIcon-propertyForeground)}.monaco-editor .codicon.codicon-symbol-reference,.monaco-workbench .codicon.codicon-symbol-reference{color:var(--vscode-symbolIcon-referenceForeground)}.monaco-editor .codicon.codicon-symbol-snippet,.monaco-workbench .codicon.codicon-symbol-snippet{color:var(--vscode-symbolIcon-snippetForeground)}.monaco-editor .codicon.codicon-symbol-string,.monaco-workbench .codicon.codicon-symbol-string{color:var(--vscode-symbolIcon-stringForeground)}.monaco-editor .codicon.codicon-symbol-struct,.monaco-workbench .codicon.codicon-symbol-struct{color:var(--vscode-symbolIcon-structForeground)}.monaco-editor .codicon.codicon-symbol-text,.monaco-workbench .codicon.codicon-symbol-text{color:var(--vscode-symbolIcon-textForeground)}.monaco-editor .codicon.codicon-symbol-type-parameter,.monaco-workbench .codicon.codicon-symbol-type-parameter{color:var(--vscode-symbolIcon-typeParameterForeground)}.monaco-editor .codicon.codicon-symbol-unit,.monaco-workbench .codicon.codicon-symbol-unit{color:var(--vscode-symbolIcon-unitForeground)}.monaco-editor .codicon.codicon-symbol-variable,.monaco-workbench .codicon.codicon-symbol-variable{color:var(--vscode-symbolIcon-variableForeground)}.editor-banner{background:var(--vscode-banner-background);box-sizing:border-box;cursor:default;display:flex;font-size:12px;height:26px;overflow:visible;width:100%}.editor-banner .icon-container{align-items:center;display:flex;flex-shrink:0;padding:0 6px 0 10px}.editor-banner .icon-container.custom-icon{background-position:50%;background-repeat:no-repeat;background-size:16px;margin:0 6px 0 10px;padding:0;width:16px}.editor-banner .message-container{align-items:center;display:flex;line-height:26px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.editor-banner .message-container p{margin-block-end:0;margin-block-start:0}.editor-banner .message-actions-container{flex-grow:1;flex-shrink:0;line-height:26px;margin:0 4px}.editor-banner .message-actions-container a.monaco-button{margin:2px 8px;padding:0 12px;width:inherit}.editor-banner .message-actions-container a{margin-left:12px;padding:3px;text-decoration:underline}.editor-banner .action-container{padding:0 10px 0 6px}.editor-banner{background-color:var(--vscode-banner-background)}.editor-banner,.editor-banner .action-container .codicon,.editor-banner .message-actions-container .monaco-link{color:var(--vscode-banner-foreground)}.editor-banner .icon-container .codicon{color:var(--vscode-banner-iconForeground)}.monaco-editor .unicode-highlight{background-color:var(--vscode-editorUnicodeHighlight-background);border:1px solid var(--vscode-editorUnicodeHighlight-border);box-sizing:border-box}.monaco-editor .focused .selectionHighlight{background-color:var(--vscode-editor-selectionHighlightBackground);border:1px solid var(--vscode-editor-selectionHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .focused .selectionHighlight,.monaco-editor.hc-light .focused .selectionHighlight{border-style:dotted}.monaco-editor .wordHighlight{background-color:var(--vscode-editor-wordHighlightBackground);border:1px solid var(--vscode-editor-wordHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .wordHighlight,.monaco-editor.hc-light .wordHighlight{border-style:dotted}.monaco-editor .wordHighlightStrong{background-color:var(--vscode-editor-wordHighlightStrongBackground);border:1px solid var(--vscode-editor-wordHighlightStrongBorder);box-sizing:border-box}.monaco-editor.hc-black .wordHighlightStrong,.monaco-editor.hc-light .wordHighlightStrong{border-style:dotted}.monaco-editor .wordHighlightText{background-color:var(--vscode-editor-wordHighlightTextBackground);border:1px solid var(--vscode-editor-wordHighlightTextBorder);box-sizing:border-box}.monaco-editor.hc-black .wordHighlightText,.monaco-editor.hc-light .wordHighlightText{border-style:dotted}.monaco-editor .zone-widget{position:absolute;z-index:10}.monaco-editor .zone-widget .zone-widget-container{border-bottom-style:solid;border-bottom-width:0;border-top-style:solid;border-top-width:0;position:relative}.monaco-editor .iPadShowKeyboard{background:url(data:image/svg+xml;base64,PHN2ZyB4bWxucz0iaHR0cDovL3d3dy53My5vcmcvMjAwMC9zdmciIHdpZHRoPSI1MyIgaGVpZ2h0PSIzNiIgZmlsbD0ibm9uZSI+PGcgY2xpcC1wYXRoPSJ1cmwoI2EpIj48cGF0aCBmaWxsPSIjNDI0MjQyIiBmaWxsLXJ1bGU9ImV2ZW5vZGQiIGQ9Ik00OC4wMzYgNC4wMUg0LjAwOHYyOC4wMmg0NC4wMjh6TTQuMDA4LjAwOEE0LjAwMyA0LjAwMyAwIDAgMCAuMDA1IDQuMDF2MjguMDJhNC4wMDMgNC4wMDMgMCAwIDAgNC4wMDMgNC4wMDJoNDQuMDI4YTQuMDAzIDQuMDAzIDAgMCAwIDQuMDAzLTQuMDAyVjQuMDFBNC4wMDMgNC4wMDMgMCAwIDAgNDguMDM2LjAwOHpNOC4wMSA4LjAxM2g0LjAwM3Y0LjAwM0g4LjAxem0xMi4wMDggMGgtNC4wMDJ2NC4wMDNoNC4wMDJ6bTQuMDAzIDBoNC4wMDJ2NC4wMDNoLTQuMDAyem0xMi4wMDggMGgtNC4wMDN2NC4wMDNoNC4wMDN6bTQuMDAyIDBoNC4wMDN2NC4wMDNINDAuMDN6bS0yNC4wMTUgOC4wMDVIOC4wMXY0LjAwM2g4LjAwNnptNC4wMDIgMGg0LjAwM3Y0LjAwM2gtNC4wMDN6bTEyLjAwOCAwaC00LjAwM3Y0LjAwM2g0LjAwM3ptMTIuMDA4IDB2NC4wMDNoLTguMDA1di00LjAwM3ptLTMyLjAyMSA4LjAwNUg4LjAxdjQuMDAzaDQuMDAzem00LjAwMyAwaDIwLjAxM3Y0LjAwM0gxNi4wMTZ6bTI4LjAxOCAwSDQwLjAzdjQuMDAzaDQuMDAzeiIgY2xpcC1ydWxlPSJldmVub2RkIi8+PC9nPjxkZWZzPjxjbGlwUGF0aCBpZD0iYSI+PHBhdGggZmlsbD0iI2ZmZiIgZD0iTTAgMGg1M3YzNkgweiIvPjwvY2xpcFBhdGg+PC9kZWZzPjwvc3ZnPg==) 50% no-repeat;border:4px solid #f6f6f6;border-radius:4px;height:36px;margin:0;min-height:0;min-width:0;overflow:hidden;padding:0;position:absolute;resize:none;width:58px}.monaco-editor.vs-dark .iPadShowKeyboard{background:url(data:image/svg+xml;base64,PHN2ZyB4bWxucz0iaHR0cDovL3d3dy53My5vcmcvMjAwMC9zdmciIHdpZHRoPSI1MyIgaGVpZ2h0PSIzNiIgZmlsbD0ibm9uZSI+PGcgY2xpcC1wYXRoPSJ1cmwoI2EpIj48cGF0aCBmaWxsPSIjQzVDNUM1IiBmaWxsLXJ1bGU9ImV2ZW5vZGQiIGQ9Ik00OC4wMzYgNC4wMUg0LjAwOHYyOC4wMmg0NC4wMjh6TTQuMDA4LjAwOEE0LjAwMyA0LjAwMyAwIDAgMCAuMDA1IDQuMDF2MjguMDJhNC4wMDMgNC4wMDMgMCAwIDAgNC4wMDMgNC4wMDJoNDQuMDI4YTQuMDAzIDQuMDAzIDAgMCAwIDQuMDAzLTQuMDAyVjQuMDFBNC4wMDMgNC4wMDMgMCAwIDAgNDguMDM2LjAwOHpNOC4wMSA4LjAxM2g0LjAwM3Y0LjAwM0g4LjAxem0xMi4wMDggMGgtNC4wMDJ2NC4wMDNoNC4wMDJ6bTQuMDAzIDBoNC4wMDJ2NC4wMDNoLTQuMDAyem0xMi4wMDggMGgtNC4wMDN2NC4wMDNoNC4wMDN6bTQuMDAyIDBoNC4wMDN2NC4wMDNINDAuMDN6bS0yNC4wMTUgOC4wMDVIOC4wMXY0LjAwM2g4LjAwNnptNC4wMDIgMGg0LjAwM3Y0LjAwM2gtNC4wMDN6bTEyLjAwOCAwaC00LjAwM3Y0LjAwM2g0LjAwM3ptMTIuMDA4IDB2NC4wMDNoLTguMDA1di00LjAwM3ptLTMyLjAyMSA4LjAwNUg4LjAxdjQuMDAzaDQuMDAzem00LjAwMyAwaDIwLjAxM3Y0LjAwM0gxNi4wMTZ6bTI4LjAxOCAwSDQwLjAzdjQuMDAzaDQuMDAzeiIgY2xpcC1ydWxlPSJldmVub2RkIi8+PC9nPjxkZWZzPjxjbGlwUGF0aCBpZD0iYSI+PHBhdGggZmlsbD0iI2ZmZiIgZD0iTTAgMGg1M3YzNkgweiIvPjwvY2xpcFBhdGg+PC9kZWZzPjwvc3ZnPg==) 50% no-repeat;border:4px solid #252526}.monaco-editor .tokens-inspect-widget{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);padding:10px;user-select:text;-webkit-user-select:text;z-index:50}.monaco-editor.hc-black .tokens-inspect-widget,.monaco-editor.hc-light .tokens-inspect-widget{border-width:2px}.monaco-editor .tokens-inspect-widget .tokens-inspect-separator{background-color:var(--vscode-editorHoverWidget-border);border:0;height:1px}.monaco-editor .tokens-inspect-widget .tm-token{font-family:var(--monaco-monospace-font)}.monaco-editor .tokens-inspect-widget .tm-token-length{float:right;font-size:60%;font-weight:400}.monaco-editor .tokens-inspect-widget .tm-metadata-table{width:100%}.monaco-editor .tokens-inspect-widget .tm-metadata-value{font-family:var(--monaco-monospace-font);text-align:right}.monaco-editor .tokens-inspect-widget .tm-token-type{font-family:var(--monaco-monospace-font)}.quick-input-widget{font-size:13px}.quick-input-widget .monaco-highlighted-label .highlight{color:#0066bf}.vs .quick-input-widget .monaco-list-row.focused .monaco-highlighted-label .highlight{color:#9dddff}.vs-dark .quick-input-widget .monaco-highlighted-label .highlight{color:#0097fb}.hc-black .quick-input-widget .monaco-highlighted-label .highlight{color:#f38518}.hc-light .quick-input-widget .monaco-highlighted-label .highlight{color:#0f4a85}.monaco-keybinding>.monaco-keybinding-key{background-color:#dedede66;border:1px solid;border-color:#ccc6 #ccc6 #bababa66;box-shadow:inset 0 -1px 0 #bababa66;color:#555}.hc-black .monaco-keybinding>.monaco-keybinding-key{background-color:initial;border:1px solid #6fc3df;box-shadow:none;color:#fff}.hc-light .monaco-keybinding>.monaco-keybinding-key{background-color:initial;border:1px solid #0f4a85;box-shadow:none;color:#292929}.vs-dark .monaco-keybinding>.monaco-keybinding-key{background-color:#8080802b;border:1px solid;border-color:#3339 #3339 #4449;box-shadow:inset 0 -1px 0 #4449;color:#ccc}.monaco-editor{--monaco-monospace-font:"SF Mono",Monaco,Menlo,Consolas,"Ubuntu Mono","Liberation Mono","DejaVu Sans Mono","Courier New",monospace;font-family:-apple-system,BlinkMacSystemFont,Segoe WPC,Segoe UI,HelveticaNeue-Light,system-ui,Ubuntu,Droid Sans,sans-serif}.monaco-editor.hc-black .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-editor.hc-light .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-editor.vs-dark .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-menu .monaco-action-bar.vertical .action-item .action-menu-item:focus .action-label{stroke-width:1.2px}.monaco-hover p{margin:0}.monaco-aria-container{clip:rect(1px,1px,1px,1px);clip-path:inset(50%);height:1px;margin:-1px;overflow:hidden;padding:0;position:absolute!important;top:0;width:1px}.monaco-diff-editor .synthetic-focus,.monaco-diff-editor [tabindex="-1"]:focus,.monaco-diff-editor [tabindex="0"]:focus,.monaco-diff-editor button:focus,.monaco-diff-editor input[type=button]:focus,.monaco-diff-editor input[type=checkbox]:focus,.monaco-diff-editor input[type=search]:focus,.monaco-diff-editor input[type=text]:focus,.monaco-diff-editor select:focus,.monaco-diff-editor textarea:focus,.monaco-editor{opacity:1;outline-color:var(--vscode-focusBorder);outline-offset:-1px;outline-style:solid;outline-width:1px}.action-widget{background-color:var(--vscode-editorActionList-background);border:1px solid var(--vscode-editorWidget-border)!important;border-radius:0;border-radius:5px;box-shadow:0 2px 8px var(--vscode-widget-shadow);color:var(--vscode-editorActionList-foreground);display:block;font-size:13px;max-width:80vw;min-width:160px;padding:4px;width:100%;z-index:40}.context-view-block{z-index:-1}.context-view-block,.context-view-pointerBlock{cursor:auto;height:100%;left:0;position:fixed;top:0;width:100%}.context-view-pointerBlock{z-index:2}.action-widget .monaco-list{border:0!important;user-select:none;-webkit-user-select:none}.action-widget .monaco-list:focus:before{outline:0!important}.action-widget .monaco-list .monaco-scrollable-element{overflow:visible}.action-widget .monaco-list .monaco-list-row{border-radius:4px;cursor:pointer;padding:0 10px;touch-action:none;white-space:nowrap;width:100%}.action-widget .monaco-list .monaco-list-row.action.focused:not(.option-disabled){background-color:var(--vscode-editorActionList-focusBackground)!important;color:var(--vscode-editorActionList-focusForeground);outline:1px solid var(--vscode-menu-selectionBorder,#0000);outline-offset:-1px}.action-widget .monaco-list-row.group-header{color:var(--vscode-descriptionForeground)!important;font-size:12px;font-weight:600}.action-widget .monaco-list-row.group-header:not(:first-of-type){margin-top:2px}.action-widget .monaco-list .group-header,.action-widget .monaco-list .option-disabled,.action-widget .monaco-list .option-disabled .focused,.action-widget .monaco-list .option-disabled .focused:before,.action-widget .monaco-list .option-disabled:before{-webkit-touch-callout:none;background-color:initial!important;cursor:default!important;outline:0 solid!important;-webkit-user-select:none;user-select:none}.action-widget .monaco-list-row.action{align-items:center;display:flex;gap:8px}.action-widget .monaco-list-row.action.option-disabled,.action-widget .monaco-list-row.action.option-disabled .codicon,.action-widget .monaco-list:focus .monaco-list-row.focused.action.option-disabled,.action-widget .monaco-list:not(.drop-target):not(.dragging) .monaco-list-row:hover:not(.selected):not(.focused).option-disabled{color:var(--vscode-disabledForeground)}.action-widget .monaco-list-row.action:not(.option-disabled) .codicon{color:inherit}.action-widget .monaco-list-row.action .title{flex:1 1;overflow:hidden;text-overflow:ellipsis}.action-widget .monaco-list-row.action .monaco-keybinding>.monaco-keybinding-key{background-color:var(--vscode-keybindingLabel-background);border-color:var(--vscode-keybindingLabel-border);border-bottom:1px var(--vscode-keybindingLabel-bottomBorder);border-left-width:1px;border-radius:3px;border-right-width:1px;border-style:solid;border-top-width:1px;box-shadow:inset 0 -1px 0 var(--vscode-widget-shadow);color:var(--vscode-keybindingLabel-foreground)}.action-widget .action-widget-action-bar{background-color:var(--vscode-editorActionList-background);border-top:1px solid var(--vscode-editorHoverWidget-border);margin-top:2px}.action-widget .action-widget-action-bar:before{content:"";display:block;width:100%}.action-widget .action-widget-action-bar .actions-container{padding:3px 8px 0}.action-widget-action-bar .action-label{color:var(--vscode-textLink-activeForeground);font-size:12px;line-height:22px;padding:0;pointer-events:all}.action-widget-action-bar .action-item{margin-right:16px;pointer-events:none}.action-widget-action-bar .action-label:hover{background-color:initial!important}.monaco-action-bar .actions-container.highlight-toggled .action-label.checked{background:var(--vscode-actionBar-toggledBackground)!important}.monaco-action-bar .action-item.menu-entry .action-label.icon{background-position:50%;background-repeat:no-repeat;background-size:16px;height:16px;width:16px}.monaco-action-bar .action-item.menu-entry.text-only .action-label{border-radius:2px;color:var(--vscode-descriptionForeground);overflow:hidden}.monaco-action-bar .action-item.menu-entry.text-only.use-comma:not(:last-of-type) .action-label:after{content:", "}.monaco-action-bar .action-item.menu-entry.text-only+.action-item:not(.text-only)>.monaco-dropdown .action-label{color:var(--vscode-descriptionForeground)}.monaco-dropdown-with-default{border-radius:5px;display:flex!important;flex-direction:row}.monaco-dropdown-with-default>.action-container>.action-label{margin-right:0}.monaco-dropdown-with-default>.action-container.menu-entry>.action-label.icon{background-position:50%;background-repeat:no-repeat;background-size:16px;height:16px;width:16px}.monaco-dropdown-with-default:hover{background-color:var(--vscode-toolbar-hoverBackground)}.monaco-dropdown-with-default>.dropdown-action-container>.monaco-dropdown>.dropdown-label .codicon[class*=codicon-]{font-size:12px;line-height:16px;margin-left:-3px;padding-left:0;padding-right:0}.monaco-dropdown-with-default>.dropdown-action-container>.monaco-dropdown>.dropdown-label>.action-label{background-position:50%;background-repeat:no-repeat;background-size:16px;display:block}.monaco-link{color:var(--vscode-textLink-foreground)}.monaco-link:hover{color:var(--vscode-textLink-activeForeground)}.quick-input-widget{-webkit-app-region:no-drag;border-radius:6px;left:50%;margin-left:-300px;position:absolute;width:600px;z-index:2550}.quick-input-titlebar{align-items:center;border-top-left-radius:5px;border-top-right-radius:5px;display:flex}.quick-input-left-action-bar{display:flex;flex:1 1;margin-left:4px}.quick-input-inline-action-bar{margin:2px 0 0 5px}.quick-input-title{overflow:hidden;padding:3px 0;text-align:center;text-overflow:ellipsis}.quick-input-right-action-bar{display:flex;flex:1 1;margin-right:4px}.quick-input-right-action-bar>.actions-container{justify-content:flex-end}.quick-input-titlebar .monaco-action-bar .action-label.codicon{background-position:50%;background-repeat:no-repeat;padding:2px}.quick-input-description{margin:6px 6px 6px 11px}.quick-input-header .quick-input-description{flex:1 1;margin:4px 2px}.quick-input-header{display:flex;padding:8px 6px 2px}.quick-input-widget.hidden-input .quick-input-header{margin-bottom:0;padding:0}.quick-input-and-message{display:flex;flex-direction:column;flex-grow:1;min-width:0;position:relative}.quick-input-check-all{align-self:center;margin:0}.quick-input-filter{display:flex;flex-grow:1;position:relative}.quick-input-box{flex-grow:1}.quick-input-widget.show-checkboxes .quick-input-box,.quick-input-widget.show-checkboxes .quick-input-message{margin-left:5px}.quick-input-visible-count{left:-10000px;position:absolute}.quick-input-count{align-items:center;align-self:center;display:flex;position:absolute;right:4px}.quick-input-count .monaco-count-badge{border-radius:2px;line-height:normal;min-height:auto;padding:2px 4px;vertical-align:middle}.quick-input-action{margin-left:6px}.quick-input-action .monaco-text-button{align-items:center;display:flex;font-size:11px;height:25px;padding:0 6px}.quick-input-message{margin-top:-1px;overflow-wrap:break-word;padding:5px}.quick-input-message>.codicon{margin:0 .2em;vertical-align:text-bottom}.quick-input-message a{color:inherit}.quick-input-progress.monaco-progress-container{position:relative}.quick-input-list{line-height:22px}.quick-input-widget.hidden-input .quick-input-list{margin-top:4px;padding-bottom:4px}.quick-input-list .monaco-list{max-height:440px;overflow:hidden;padding-bottom:5px}.quick-input-list .monaco-scrollable-element{padding:0 5px}.quick-input-list .quick-input-list-entry{box-sizing:border-box;display:flex;overflow:hidden;padding:0 6px}.quick-input-list .quick-input-list-entry.quick-input-list-separator-border{border-top-style:solid;border-top-width:1px}.quick-input-list .monaco-list-row{border-radius:3px}.quick-input-list .monaco-list-row[data-index="0"] .quick-input-list-entry.quick-input-list-separator-border{border-top-style:none}.quick-input-list .quick-input-list-label{display:flex;flex:1 1;height:100%;overflow:hidden}.quick-input-list .quick-input-list-checkbox{align-self:center;margin:0}.quick-input-list .quick-input-list-icon{align-items:center;background-position:0;background-repeat:no-repeat;background-size:16px;display:flex;height:22px;justify-content:center;padding-right:6px;width:16px}.quick-input-list .quick-input-list-rows{display:flex;flex:1 1;flex-direction:column;height:100%;margin-left:5px;overflow:hidden;text-overflow:ellipsis}.quick-input-widget.show-checkboxes .quick-input-list .quick-input-list-rows{margin-left:10px}.quick-input-widget .quick-input-list .quick-input-list-checkbox{display:none}.quick-input-widget.show-checkboxes .quick-input-list .quick-input-list-checkbox{display:inline}.quick-input-list .quick-input-list-rows>.quick-input-list-row{align-items:center;display:flex}.quick-input-list .quick-input-list-rows>.quick-input-list-row .monaco-icon-label,.quick-input-list .quick-input-list-rows>.quick-input-list-row .monaco-icon-label .monaco-icon-label-container>.monaco-icon-name-container{flex:1 1}.quick-input-list .quick-input-list-rows>.quick-input-list-row .codicon[class*=codicon-]{vertical-align:text-bottom}.quick-input-list .quick-input-list-rows .monaco-highlighted-label>span{opacity:1}.quick-input-list .quick-input-list-entry .quick-input-list-entry-keybinding{margin-right:8px}.quick-input-list .quick-input-list-label-meta{line-height:normal;opacity:.7;overflow:hidden;text-overflow:ellipsis}.quick-input-list .monaco-list .monaco-list-row .monaco-highlighted-label .highlight{background-color:unset;color:var(--vscode-list-highlightForeground)!important;font-weight:700}.quick-input-list .monaco-list .monaco-list-row.focused .monaco-highlighted-label .highlight{color:var(--vscode-list-focusHighlightForeground)!important}.quick-input-list .quick-input-list-entry .quick-input-list-separator{margin-right:4px}.quick-input-list .quick-input-list-entry-action-bar{display:flex;flex:0 1;overflow:visible}.quick-input-list .quick-input-list-entry-action-bar .action-label{display:none}.quick-input-list .quick-input-list-entry-action-bar .action-label.codicon{margin-right:4px;padding:2px}.quick-input-list .quick-input-list-entry-action-bar{margin-right:4px;margin-top:1px}.quick-input-list .monaco-list-row.focused .quick-input-list-entry-action-bar .action-label,.quick-input-list .monaco-list-row.passive-focused .quick-input-list-entry-action-bar .action-label,.quick-input-list .quick-input-list-entry .quick-input-list-entry-action-bar .action-label.always-visible,.quick-input-list .quick-input-list-entry.focus-inside .quick-input-list-entry-action-bar .action-label,.quick-input-list .quick-input-list-entry:hover .quick-input-list-entry-action-bar .action-label{display:flex}.quick-input-list .monaco-list-row.focused .monaco-keybinding-key,.quick-input-list .monaco-list-row.focused .quick-input-list-entry .quick-input-list-separator{color:inherit}.quick-input-list .monaco-list-row.focused .monaco-keybinding-key{background:none}.quick-input-list .quick-input-list-separator-as-item{font-size:12px;padding:4px 6px}.quick-input-list .quick-input-list-separator-as-item .label-name{font-weight:600}.quick-input-list .quick-input-list-separator-as-item .label-description{opacity:1!important}.quick-input-list .monaco-tree-sticky-row .quick-input-list-entry.quick-input-list-separator-as-item.quick-input-list-separator-border{border-top-style:none}.quick-input-list .monaco-tree-sticky-row{padding:0 5px}.quick-input-list .monaco-tl-twistie{display:none!important}.extension-editor .codicon.codicon-error,.extensions-viewlet>.extensions .codicon.codicon-error,.markers-panel .marker-icon .codicon.codicon-error,.markers-panel .marker-icon.error,.monaco-editor .zone-widget .codicon.codicon-error,.preferences-editor .codicon.codicon-error,.text-search-provider-messages .providerMessage .codicon.codicon-error{color:var(--vscode-problemsErrorIcon-foreground)}.extension-editor .codicon.codicon-warning,.extensions-viewlet>.extensions .codicon.codicon-warning,.markers-panel .marker-icon .codicon.codicon-warning,.markers-panel .marker-icon.warning,.monaco-editor .zone-widget .codicon.codicon-warning,.preferences-editor .codicon.codicon-warning,.text-search-provider-messages .providerMessage .codicon.codicon-warning{color:var(--vscode-problemsWarningIcon-foreground)}.extension-editor .codicon.codicon-info,.extensions-viewlet>.extensions .codicon.codicon-info,.markers-panel .marker-icon .codicon.codicon-info,.markers-panel .marker-icon.info,.monaco-editor .zone-widget .codicon.codicon-info,.preferences-editor .codicon.codicon-info,.text-search-provider-messages .providerMessage .codicon.codicon-info{color:var(--vscode-problemsInfoIcon-foreground)}.ydb-navigation-tree-view-empty{color:var(--g-color-text-secondary);font-style:italic}.ydb-navigation-tree-view-error{color:var(--g-color-text-danger)}.ydb-navigation-tree-view-loader{align-items:center;display:flex;height:24px;justify-content:center;width:20px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/35614.b1faff6b.chunk.css b/ydb/core/viewer/monitoring/static/css/35614.b1faff6b.chunk.css new file mode 100644 index 000000000000..082605d3ab43 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/35614.b1faff6b.chunk.css @@ -0,0 +1 @@ +.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-storage-group-page{height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-storage-group-page__info,.ydb-storage-group-page__meta,.ydb-storage-group-page__storage-title,.ydb-storage-group-page__title{left:0;margin-bottom:20px;position:sticky}.ydb-storage-group-page__meta{margin-top:20px}.ydb-storage-group-page__title{margin-bottom:60px}.ydb-storage-group-page__storage-title{font-size:var(--g-text-header-1-font-size);line-height:var(--g-text-header-1-line-height);margin-bottom:0}.ydb-storage-group-page__info{margin-top:var(--g-spacing-10)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/35742.54c83566.chunk.css b/ydb/core/viewer/monitoring/static/css/35742.54c83566.chunk.css new file mode 100644 index 000000000000..72dc02be740d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/35742.54c83566.chunk.css @@ -0,0 +1 @@ +@charset "UTF-8";.ydb-entity-status-new .g-help-mark__button{color:inherit}.ydb-entity-status-new_orange.g-label{background-color:var(--g-color-private-orange-100);color:var(--g-color-private-orange-500)}.ydb-nodes__search{width:238px}.ydb-nodes__show-all-wrapper{left:0;margin-bottom:15px;position:sticky}.ydb-nodes__node_unavailable{opacity:.6}.kv-shorty-string__toggle{font-size:.85em;margin-left:1em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.tenants__format-label{margin-right:15px}.tenants__title{text-align:center}.tenants__tooltip{animation:none!important}.tenants__search{width:238px}.tenants__tablets{padding:0!important}.tenants__tablets .tablets-viewer__grid{grid-gap:20px}.tenants__type{align-items:center;display:flex;flex-direction:row;gap:10px}.tenants__type-value{overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:min-content}.tenants__type-button{display:none}.data-table__row:hover .tenants__type-button{display:block}.tenants__name{overflow:hidden}.tenants__table-wrapper{display:contents;width:max-content}.tenants__create-database{margin:0 0 0 auto;position:sticky;right:calc(var(--cluster-side-padding)*2)}.tenants__remove-db{color:var(--ydb-color-status-red)}.ydb-cluster-versions-bar{display:flex;flex-direction:column;min-width:600px}.ydb-cluster-versions-bar .g-progress{width:100%}.ydb-cluster-versions-bar__versions{display:flex;flex-flow:row wrap;margin-top:6px}.ydb-cluster-versions-bar__version-title{margin-left:3px;white-space:nowrap}.ydb-cluster-versions-bar .g-progress__stack{cursor:pointer}.g-progress{--_--empty-background-color:var(--g-color-base-generic);--_--empty-text-color:var(--g-color-text-primary);--_--filled-text-color:var(--g-color-text-primary);--_--filled-background-color:var(--g-color-base-neutral-medium);background-color:var(--g-progress-empty-background-color,var(--_--empty-background-color));border-radius:3px;margin:0 auto;overflow:hidden;position:relative;text-align:center}.g-progress__text{color:var(--g-progress-empty-text-color,var(--_--empty-text-color));position:relative}.g-progress__text,.g-progress__text-inner{box-sizing:border-box;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);padding:0 10px}.g-progress__text-inner{color:var(--g-progress-filled-text-color,var(--_--empty-text-color));height:100%;position:absolute;transition:transform .6s ease;width:100%}.g-progress__item{background-color:var(--g-progress-filled-background-color,var(--_--filled-background-color));float:left;height:100%;overflow:hidden;position:relative;transition:transform .6s ease,width .6s ease,background-color .6s ease;width:100%}[dir=rtl] .g-progress__item{float:right}.g-progress__item_theme_default{--_--filled-background-color:var(--g-color-base-neutral-medium)}.g-progress__item_theme_success{--_--filled-background-color:var(--g-color-base-positive-medium)}.g-progress__item_theme_warning{--_--filled-background-color:var(--g-color-base-warning-medium)}.g-progress__item_theme_danger{--_--filled-background-color:var(--g-color-base-danger-medium)}.g-progress__item_theme_info{--_--filled-background-color:var(--g-color-base-info-medium)}.g-progress__item_theme_misc{--_--filled-background-color:var(--g-color-base-misc-medium)}.g-progress__item_loading{animation:g-loading-animation .5s linear infinite;background-clip:padding-box;background-image:repeating-linear-gradient(-45deg,#ffffff4d,#ffffff4d 4px,#0000 0,#0000 8px);background-size:150%}.g-progress__stack{color:var(--g-color-text-light-primary);margin:0 auto;overflow:hidden;position:relative;transition:transform .6s ease;width:100%}.g-progress_size_m,.g-progress_size_m .g-progress__stack{height:20px;line-height:20px}.g-progress_size_m .g-progress__text{height:20px;margin-block-end:-20px}.g-progress_size_s,.g-progress_size_s .g-progress__stack{height:10px;line-height:10px}.g-progress_size_xs,.g-progress_size_xs .g-progress__stack{height:4px;line-height:4px}.g-progress_size_s .g-progress__text,.g-progress_size_s .g-progress__text-inner,.g-progress_size_xs .g-progress__text,.g-progress_size_xs .g-progress__text-inner{display:none}.ydb-versions-nodes-tree-title__overview{align-items:center;display:flex;justify-content:space-between;width:100%}.ydb-versions-nodes-tree-title__overview-info{align-items:center;display:flex;margin-left:25px}.ydb-versions-nodes-tree-title__overview-info>:not(:first-child){margin-left:30px}.ydb-versions-nodes-tree-title__overview-container{align-items:center;display:flex}.ydb-versions-nodes-tree-title__info-label{color:var(--g-color-text-complementary);font-weight:200}.ydb-versions-nodes-tree-title__info-label_margin_left{margin-left:5px}.ydb-versions-nodes-tree-title__info-label_margin_right{margin-right:5px}.ydb-versions-nodes-tree-title__version-color{border-radius:100%;height:16px;margin-right:10px;width:16px}.ydb-versions-nodes-tree-title__version-progress{align-items:center;display:flex;width:250px}.ydb-versions-nodes-tree-title__version-progress .g-progress{width:200px}.ydb-versions-nodes-tree-title__overview-title{align-items:center;display:flex}.ydb-versions-nodes-tree-title__clipboard-button{color:var(--g-color-text-secondary);margin-left:8px;opacity:0}.ydb-tree-view__item:hover .ydb-versions-nodes-tree-title__clipboard-button,.ydb-versions-nodes-tree-title__clipboard-button:focus-visible{opacity:1}.ydb-versions-grouped-node-tree_first-level{border:1px solid var(--g-color-line-generic);border-radius:10px;margin-bottom:10px;margin-top:10px}.ydb-versions-grouped-node-tree__dt-wrapper{margin-left:24px;margin-right:24px;overflow:auto hidden;position:relative;z-index:0}.ydb-versions-grouped-node-tree .ydb-tree-view{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-versions-grouped-node-tree .ydb-tree-view .ydb-tree-view{margin-left:24px}.ydb-versions-grouped-node-tree .tree-view_item{border:0;border-radius:10px;height:40px;margin:0;padding:0 10px!important}.ydb-versions-grouped-node-tree .tree-view_children .tree-view_item{width:100%}.ydb-versions-grouped-node-tree .g-progress__stack{cursor:pointer}.ydb-tree-view{--ydb-tree-view-level:0;font-size:13px;line-height:18px}.ydb-tree-view,.ydb-tree-view *{box-sizing:border-box}.ydb-tree-view__item{align-items:center;border-bottom:1px solid var(--g-color-line-generic-solid);cursor:pointer;display:flex;height:24px;padding-left:calc(24px*var(--ydb-tree-view-level));padding-right:3px}.ydb-tree-view__item:hover{background-color:var(--g-color-base-simple-hover)}.ydb-tree-view__item:hover .ydb-tree-view__actions{display:flex}.ydb-tree-view__item_active{background-color:var(--g-color-base-selection);font-weight:700}.ydb-tree-view__item_active:hover{background-color:var(--g-color-base-selection-hover)}.ydb-tree-view__content{align-items:center;display:flex;flex-grow:1;overflow:hidden}.ydb-tree-view__icon{align-items:center;color:var(--g-color-text-hint);display:flex;flex-shrink:0;height:24px;justify-content:center;width:24px}.ydb-tree-view__icon svg{display:block}.ydb-tree-view__text{flex-grow:1;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-tree-view__actions{align-items:center;display:none;margin-left:6px}.ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%;border:none;cursor:pointer;flex-shrink:0;height:24px;padding:0;width:24px}.g-root_theme_dark .ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%}.ydb-tree-view__arrow:focus-visible{outline:2px solid var(--g-color-line-focus)}.ydb-tree-view__arrow:not(.ydb-tree-view__arrow_collapsed){transform:rotate(90deg)}.ydb-tree-view__arrow_hidden{visibility:hidden}.ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:24px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:48px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:72px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:96px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:120px}.ydb-versions{--ydb-info-viewer-font-size:var(--g-text-body-2-font-size);--ydb-info-viewer-line-height:var(--g-text-body-2-line-height);font-size:var(--ydb-info-viewer-font-size);line-height:var(--ydb-info-viewer-line-height)}.ydb-versions__controls{align-items:center;display:flex;padding:0 0 20px}.ydb-versions__controls .ydb-versions__label{font-weight:500;margin-right:10px}.ydb-versions__controls .ydb-versions__checkbox{margin:0}.ydb-versions__controls>*{margin-right:25px}.ydb-versions__overall-wrapper{border:1px solid var(--g-color-line-generic);border-radius:10px;margin-bottom:10px;margin-top:10px;padding:20px}.ydb-versions__overall-progress{border-radius:5px;height:20px;line-height:20px}.ydb-versions__overall-progress .g-progress__stack{height:20px;line-height:20px}.ydb-disk-groups-stats{--g-definition-list-item-gap:var(--g-spacing-3);background-color:var(--g-color-base-generic-ultralight);border-radius:var(--g-border-radius-s);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);padding:var(--g-spacing-3) var(--g-spacing-4);width:287px}.ydb-disk-groups-stats__progress{display:inline-block;width:60px}.cluster-info{--g-definition-list-item-gap:var(--g-spacing-3);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);padding:var(--g-spacing-4) 0 var(--g-spacing-2)}.cluster-info__skeleton{margin-top:5px}.cluster-info__dc{height:20px}.cluster-info__clipboard-button{align-items:center;display:flex;margin-left:5px}.ydb-doughnut-metrics{--doughnut-border:16px;--doughnut-color:var(--ydb-color-status-green);--doughnut-backdrop-color:var(--g-color-base-positive-light);--doughnut-overlap-color:var(--g-color-base-positive-heavy-hover)}.ydb-doughnut-metrics__doughnut{aspect-ratio:1;border-radius:50%;position:relative;transform:rotate(180deg);width:100px}.ydb-doughnut-metrics__doughnut:before{aspect-ratio:1;background-color:var(--g-color-base-background);border-radius:50%;content:"";display:block;height:calc(100% - var(--doughnut-border)*2);transform:translate(var(--doughnut-border),var(--doughnut-border))}.ydb-doughnut-metrics__doughnut_status_warning{--doughnut-color:var(--ydb-color-status-yellow);--doughnut-backdrop-color:var(--g-color-base-warning-light);--doughnut-overlap-color:var(--g-color-base-warning-heavy-hover)}.ydb-doughnut-metrics__doughnut_status_danger{--doughnut-color:var(--ydb-color-status-red);--doughnut-backdrop-color:var(--g-color-base-danger-light);--doughnut-overlap-color:var(--g-color-base-danger-heavy-hover)}.ydb-doughnut-metrics__text-wrapper{--wrapper-indent:calc(var(--doughnut-border) + 5px);align-items:center;aspect-ratio:1;display:flex;flex-direction:column;justify-content:center;position:absolute;right:var(--wrapper-indent);text-align:center;top:var(--wrapper-indent);transform:rotate(180deg);width:calc(100% - var(--wrapper-indent)*2)}.ydb-doughnut-metrics__value{bottom:20px;position:absolute}.ydb-doughnut-metrics__legend-note{display:flex}.ydb-cluster-dashboard__dashboard-wrapper{gap:var(--g-spacing-6);padding-top:var(--g-spacing-4)}.ydb-cluster-dashboard__dashboard-wrapper_collapsed{gap:var(--g-spacing-1);margin-left:auto;margin-right:var(--g-spacing-4);padding-top:unset}.ydb-cluster-dashboard__error{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-cluster-dashboard__skeleton-wrapper{border:unset;padding:unset}.ydb-cluster-dashboard__skeleton{height:100%}.ydb-cluster-dashboard__overview-wrapper{--g-button-background-color-hover:var(--g-color-base-background);--g-button-padding:0;border:1px solid var(--g-color-line-generic);border-radius:5px;padding:var(--g-spacing-4)}.ydb-cluster-dashboard__overview-wrapper .g-button:active{transform:unset}.ydb-cluster-dashboard__overview-wrapper_collapsed:hover{border-color:var(--g-color-line-generic-hover)}.ydb-cluster-dashboard__disclosure-summary{align-items:center;cursor:pointer;display:flex;height:28px;justify-content:space-between;width:100%}.ydb-cluster-dashboard__disclosure-summary .g-button__text{width:100%}.ydb-cluster-dashboard__card{height:132px;min-width:280px}.ydb-cluster-dashboard__card_collapsed{height:28px;min-width:120px}.g-disclosure_size_m .g-disclosure__trigger{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-disclosure_size_l .g-disclosure__trigger{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-disclosure_size_xl .g-disclosure__trigger{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-disclosure__trigger{align-items:center;background:none;border:none;border-radius:var(--g-focus-border-radius);color:inherit;cursor:pointer;display:flex;flex-flow:row nowrap;flex-shrink:0;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);font-weight:inherit;gap:8px;line-height:inherit;outline:none;padding:0}.g-disclosure__trigger:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-disclosure__trigger_arrow_end{flex-direction:row-reverse}.g-disclosure__trigger_disabled{color:var(--g-color-text-secondary);cursor:auto}.g-disclosure__content{display:none}.g-disclosure__content_visible{display:block}.g-disclosure__content.g-disclosure_exit_active{animation-duration:.1s;animation-name:g-disclosure-collapsed;display:block;opacity:0}.g-disclosure__content.g-disclosure_enter_active{animation-duration:.2s;animation-name:g-disclosure-expanded}@keyframes g-disclosure-expanded{0%{opacity:.4}to{opacity:1}}@keyframes g-disclosure-collapsed{0%{opacity:1}to{opacity:0}}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-cluster{--cluster-side-padding:var(--g-spacing-5);--sticky-tabs-height:40px;height:100%;overflow:auto;position:relative;width:100%}.ydb-cluster__dashboard,.ydb-cluster__sticky-wrapper{padding:0 var(--cluster-side-padding)}.ydb-cluster__dashboard{left:0;position:sticky}.ydb-cluster__content{min-height:calc(100% - var(--sticky-tabs-height, 0px));transform:translateX(var(--cluster-side-padding));width:calc(100% - var(--cluster-side-padding))}.ydb-cluster__header{left:0;padding:var(--g-spacing-5) var(--cluster-side-padding);position:sticky}.ydb-cluster__title{font-size:var(--g-text-header-1-font-size);font-weight:var(--g-text-header-font-weight);line-height:var(--g-text-header-1-line-height)}.ydb-cluster__title-skeleton{height:var(--g-text-header-1-line-height);min-width:200px;width:20%}.ydb-cluster__tabs-sticky-wrapper{background-color:var(--g-color-base-background);left:0;margin-top:20px;padding:0 var(--cluster-side-padding);position:sticky;top:0;z-index:3}.ydb-cluster__tabs{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic);display:flex}.ydb-cluster__sticky-wrapper{left:0;position:sticky;top:74px;z-index:4}.ydb-cluster__auto-refresh-control{background-color:var(--g-color-base-background);float:right;margin-top:-54px}.ydb-cluster .ydb-table-with-controls-layout__controls-wrapper{top:40px}.ydb-cluster .ydb-table-with-controls-layout{--data-table-sticky-header-offset:102px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/371.01f04f12.chunk.css b/ydb/core/viewer/monitoring/static/css/371.01f04f12.chunk.css deleted file mode 100644 index f380b6f52be7..000000000000 --- a/ydb/core/viewer/monitoring/static/css/371.01f04f12.chunk.css +++ /dev/null @@ -1 +0,0 @@ -@charset "UTF-8";.tag{background:var(--g-color-base-generic);border-radius:3px;color:var(--g-color-text-primary);font-size:12px;padding:2px 5px;white-space:nowrap}.tag:last-child{margin-right:0}.tag_type_blue{background-color:var(--g-color-celestial-thunder)}.basic-node-viewer__link,.link{color:var(--g-color-text-link);text-decoration:none}.basic-node-viewer__link:hover,.link:hover{color:var(--g-color-text-link-hover)}.basic-node-viewer{align-items:center;display:flex;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin:15px 0}.basic-node-viewer__title{font-weight:600;margin:0 20px 0 0;text-transform:uppercase}.basic-node-viewer__id{margin:0 15px 0 24px}.basic-node-viewer__label{color:var(--g-color-text-hint);line-height:18px;margin-right:10px;white-space:nowrap}.basic-node-viewer__link{margin-left:5px}.ydb-pool-usage{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-pool-usage__info{align-items:center;display:flex;justify-content:space-between}.ydb-pool-usage__pool-name{color:var(--g-color-text-primary)}.ydb-pool-usage__value{align-items:center;display:flex}.ydb-pool-usage__threads{color:var(--g-color-text-hint);font-size:var(--g-text-body-1-font-size)}.ydb-pool-usage__percents{color:var(--g-color-text-primary);font-size:var(--g-text-body-1-font-size);margin-right:2px}.ydb-pool-usage__visual{align-items:center;background-color:var(--g-color-base-generic-accent);border-radius:4px;display:flex;font-size:var(--g-text-body-2-font-size);height:6px;justify-content:center;overflow:hidden;position:relative}.ydb-pool-usage__usage-line{height:100%;left:0;position:absolute;top:0}.ydb-pool-usage__usage-line_type_green{background-color:var(--ydb-color-status-green)}.ydb-pool-usage__usage-line_type_blue{background-color:var(--ydb-color-status-blue)}.ydb-pool-usage__usage-line_type_yellow{background-color:var(--ydb-color-status-yellow)}.ydb-pool-usage__usage-line_type_red{background-color:var(--ydb-color-status-red)}.full-node-viewer{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.full-node-viewer__common-info{align-items:stretch;display:flex;flex-direction:column;justify-content:flex-start}.full-node-viewer__section{border-radius:10px}.full-node-viewer__section_pools{grid-gap:7px 20px;display:grid;grid-template-columns:110px 110px}.full-node-viewer .info-viewer__label{min-width:100px}.full-node-viewer__section-title{font-weight:600;margin:15px 0 10px}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.kv-shorty-string__toggle{font-size:.85em;margin-left:2em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-resizeable-data-table{display:flex;padding-right:20px;width:max-content}.ydb-pdisk-info__links,.ydb-vdisk-info__links{display:flex;flex-flow:row wrap;gap:var(--g-spacing-2)}.ydb-vdisk-info__title{display:flex;flex-direction:row;gap:var(--g-spacing-2)}.kv-node-structure{display:flex;flex-shrink:0;flex:1 1 auto;flex-direction:column;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);overflow:auto;position:relative}.kv-node-structure__error{padding:20px 20px 0}.kv-node-structure__pdisk{border:1px solid var(--g-color-line-generic);border-radius:5px;display:flex;flex-direction:column;margin-bottom:8px;padding:0 10px 0 20px;width:573px}.kv-node-structure__pdisk-id{align-items:flex-end;display:flex}.kv-node-structure__pdisk-header{align-items:center;display:flex;height:48px;justify-content:space-between}.kv-node-structure__pdisk-title-wrapper{align-items:center;display:flex;font-weight:600;gap:16px}.kv-node-structure__pdisk-title-wrapper .entity-status__status-icon{margin-right:0}.kv-node-structure__pdisk-title-item{display:flex;gap:4px}.kv-node-structure__pdisk-title-item-label{color:var(--g-color-text-secondary);font-weight:400}.kv-node-structure__pdisk-title-id{min-width:110px}.kv-node-structure__pdisk-title-type{justify-content:flex-end;min-width:50px}.kv-node-structure__pdisk-title-size{min-width:150px}.kv-node-structure__pdisk-details{margin-bottom:20px}.kv-node-structure__link{color:var(--g-color-base-brand);text-decoration:none}.kv-node-structure__vdisks-header{font-weight:600}.kv-node-structure__vdisks-container{margin-bottom:42px}.kv-node-structure__vdisk-details{max-height:90vh;max-width:unset;min-width:200px;overflow:auto}.kv-node-structure__vdisk-details .vdisk-pdisk-node__column{margin-bottom:0}.kv-node-structure__vdisk-details .vdisk-pdisk-node__section{padding-bottom:0}.kv-node-structure__vdisk-id{align-items:center;display:flex}.kv-node-structure__vdisk-details-button_selected,.kv-node-structure__vdisk-id_selected{color:var(--g-color-text-info)}.kv-node-structure__external-button{align-items:center;display:inline-flex;margin-left:4px;transform:translateY(-1px)}.kv-node-structure__external-button_hidden{visibility:hidden}.kv-node-structure .data-table__row:hover .kv-node-structure__external-button_hidden{visibility:visible}.kv-node-structure__selected-vdisk{animation:onSelectedVdiskAnimation 4s}@keyframes onSelectedVdiskAnimation{0%{background-color:var(--g-color-base-info-light-hover)}}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.node{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.node__header{margin:16px 20px}.node__content{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto;position:relative}.node__storage{height:100%;overflow:auto;padding:0 20px}.node__tabs{--g-tabs-border-width:0;align-items:center;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic);display:flex;justify-content:space-between;padding:0 20px}.node__tab{margin-right:40px;text-decoration:none}.node__tab:last-child{margin-right:0}.node__tab:first-letter{text-transform:uppercase}.node__overview-wrapper{padding:0 20px 20px}.node__node-page-wrapper{height:100%;padding:20px}.node__error{padding:0 20px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/37171.1dcca541.chunk.css b/ydb/core/viewer/monitoring/static/css/37171.1dcca541.chunk.css new file mode 100644 index 000000000000..2fa46bda55df --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/37171.1dcca541.chunk.css @@ -0,0 +1 @@ +.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.table-skeleton__wrapper{width:100%}.table-skeleton__wrapper_hidden{visibility:hidden}.table-skeleton__row{align-items:center;display:flex;height:var(--data-table-row-height)}.table-skeleton__row .g-skeleton{height:var(--g-text-body-2-line-height)}.table-skeleton__col-1{margin-right:5%;width:10%}.table-skeleton__col-2{margin-right:5%;width:7%}.table-skeleton__col-3,.table-skeleton__col-4{margin-right:5%;width:5%}.table-skeleton__col-5{width:20%}.table-skeleton__col-full{width:100%}.ydb-table-with-controls-layout{--data-table-sticky-header-offset:62px;box-sizing:border-box;display:inline-block;min-width:100%}.ydb-table-with-controls-layout_full-height{min-height:calc(100% - var(--sticky-tabs-height, 0px))}.ydb-table-with-controls-layout__controls-wrapper{background-color:var(--g-color-base-background);box-sizing:border-box;left:0;position:sticky;top:0;width:100%;z-index:3}.ydb-table-with-controls-layout__controls{align-items:center;background-color:var(--g-color-base-background);display:flex;gap:12px;height:62px;left:0;padding:16px 0 18px;position:sticky;top:0;width:max-content;z-index:3}.ydb-table-with-controls-layout__table{position:relative;z-index:2}.ydb-table-with-controls-layout .ydb-paginated-table__head{top:var(--data-table-sticky-header-offset,62px)}.ydb-table-with-controls-layout .data-table__sticky_moving{top:var(--data-table-sticky-header-offset,62px)!important}.ydb-table-group{border:1px solid var(--g-color-line-generic);border-radius:var(--g-spacing-2);display:flex;flex-direction:column;margin-bottom:20px;min-width:100%;width:max-content}.ydb-table-group__button{background:unset;border:unset;cursor:pointer;padding:8px 0}.ydb-table-group__title-wrapper{align-items:center;display:flex;flex-direction:row;gap:var(--g-spacing-2);justify-content:flex-start;left:0;padding-left:20px;position:sticky;width:max-content}.ydb-table-group__title{display:flex;flex-direction:row;gap:var(--g-spacing-4)}.ydb-table-group__count{display:flex;flex-direction:row;gap:var(--g-spacing-3)}.ydb-table-group__content{padding:12px 0 20px 20px}.progress-viewer{align-items:center;background:var(--g-color-base-generic);border-radius:2px;color:var(--g-color-text-complementary);display:flex;font-size:var(--g-text-body-2-font-size);height:23px;justify-content:center;min-width:150px;overflow:hidden;padding:0 4px;position:relative;white-space:nowrap;z-index:0}.progress-viewer_theme_dark{color:var(--g-color-text-light-primary)}.progress-viewer_theme_dark .progress-viewer__line{opacity:.75}.progress-viewer_status_good{background-color:var(--g-color-base-positive-light)}.progress-viewer_status_good .progress-viewer__line{background-color:var(--ydb-color-status-green)}.progress-viewer_status_warning{background-color:var(--g-color-base-yellow-light)}.progress-viewer_status_warning .progress-viewer__line{background-color:var(--ydb-color-status-yellow)}.progress-viewer_status_danger{background-color:var(--g-color-base-danger-light)}.progress-viewer_status_danger .progress-viewer__line{background-color:var(--ydb-color-status-red)}.progress-viewer__line{height:100%;left:0;position:absolute;top:0}.progress-viewer__text{position:relative;z-index:1}.progress-viewer_size_xs{font-size:var(--g-text-body-2-font-size);height:20px;line-height:var(--g-text-body-2-line-height)}.progress-viewer_size_s{font-size:var(--g-text-body-1-font-size);height:28px;line-height:28px}.progress-viewer_size_m{font-size:var(--g-text-body-2-font-size);height:32px;line-height:32px}.progress-viewer_size_ns{font-size:13px;height:24px;line-height:var(--g-text-subheader-3-line-height)}.progress-viewer_size_n{font-size:var(--g-text-body-1-font-size);height:36px;line-height:36px}.progress-viewer_size_l{font-size:var(--g-text-subheader-3-font-size);height:38px;line-height:38px}.progress-viewer_size_head{font-size:var(--g-text-body-1-font-size);line-height:36px}.ydb-search{min-width:100px}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.ydb-paginated-table{--paginated-table-cell-vertical-padding:5px;--paginated-table-cell-horizontal-padding:10px;--paginated-table-border-color:var(--g-color-base-generic-hover);--paginated-table-hover-color:var(--g-color-base-simple-hover-solid);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);width:100%}.ydb-paginated-table__table{border-collapse:initial;border-spacing:0;max-width:100%;table-layout:fixed;width:max-content}.ydb-paginated-table__table th{padding:0}.ydb-paginated-table__row{position:relative;transform:translateZ(0);z-index:1}.ydb-paginated-table__row:hover{background:var(--paginated-table-hover-color)}.ydb-paginated-table__row_empty:hover{background-color:initial}.ydb-paginated-table__head{background-color:var(--g-color-base-background);left:0;position:sticky;top:0;z-index:2}.ydb-paginated-table__sort-icon-container{color:inherit;display:flex;justify-content:center}.ydb-paginated-table__sort-icon-container_shadow{opacity:.15}.ydb-paginated-table__sort-icon_desc{transform:rotate(180deg)}.ydb-paginated-table__head-cell-wrapper{border-bottom:1px solid var(--paginated-table-border-color);display:table-cell;overflow-x:hidden;position:relative}.ydb-paginated-table__head-cell{align-items:center;cursor:default;display:flex;flex-direction:row;font-weight:700;gap:var(--g-spacing-2);max-width:100%;padding:var(--paginated-table-cell-vertical-padding) var(--paginated-table-cell-horizontal-padding);width:100%}.ydb-paginated-table__head-cell_align_left{justify-content:left;text-align:left}.ydb-paginated-table__head-cell_align_center{justify-content:center;text-align:center}.ydb-paginated-table__head-cell_align_right{justify-content:right;text-align:right}.ydb-paginated-table__head-cell_align_right .ydb-paginated-table__head-cell-content-container{flex-direction:row-reverse}.ydb-paginated-table__head-cell_sortable{cursor:pointer}.ydb-paginated-table__head-cell_sortable.ydb-paginated-table__head-cell_align_right{flex-direction:row-reverse}.ydb-paginated-table__head-cell-note{display:flex}.ydb-paginated-table__head-cell-content{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-paginated-table__head-cell-content-container{display:inline-flex;gap:var(--g-spacing-1);overflow:hidden}.ydb-paginated-table__head-cell-content-container .g-help-mark__button{align-items:center;display:inline-flex}.ydb-paginated-table__row-cell{border-bottom:1px solid var(--paginated-table-border-color);display:table-cell;max-width:100%;overflow-x:hidden;padding:var(--paginated-table-cell-vertical-padding) var(--paginated-table-cell-horizontal-padding);text-overflow:ellipsis;vertical-align:middle;white-space:nowrap;width:100%}.ydb-paginated-table__row-cell_align_left{text-align:left}.ydb-paginated-table__row-cell_align_center{text-align:center}.ydb-paginated-table__row-cell_align_right{text-align:right}.ydb-paginated-table__resize-handler{background-color:var(--g-color-base-generic);cursor:col-resize;height:100%;position:absolute;right:0;top:0;visibility:hidden;width:6px}.ydb-paginated-table__head-cell-wrapper:hover>.ydb-paginated-table__resize-handler,.ydb-paginated-table__resize-handler_resizing{visibility:visible}.ydb-paginated-table__resizeable-table-container{padding-right:20px;width:max-content}.ydb-paginated-table__row-skeleton:after{display:none!important}.hover-popup{padding:var(--g-spacing-3)}.memory-viewer{min-width:150px;padding:0 var(--g-spacing-1);position:relative;z-index:0}.memory-viewer__progress-container{background:var(--g-color-base-generic);border-radius:2px;height:20px;overflow:hidden;position:relative}.memory-viewer__container{display:flex;padding:2px 0}.memory-viewer__legend{border-radius:2px;bottom:2px;height:20px;position:absolute;width:20px}.memory-viewer__legend_type_AllocatorCachesMemory{background-color:var(--g-color-base-utility-medium-hover)}.memory-viewer__legend_type_SharedCacheConsumption{background-color:var(--g-color-base-info-medium-hover)}.memory-viewer__legend_type_MemTableConsumption{background-color:var(--g-color-base-warning-medium-hover)}.memory-viewer__legend_type_QueryExecutionConsumption{background-color:var(--g-color-base-positive-medium-hover)}.memory-viewer__legend_type_Other{background-color:var(--g-color-base-generic-medium-hover)}.memory-viewer__segment{height:100%;position:absolute}.memory-viewer__segment_type_AllocatorCachesMemory{background-color:var(--g-color-base-utility-medium-hover)}.memory-viewer__segment_type_SharedCacheConsumption{background-color:var(--g-color-base-info-medium-hover)}.memory-viewer__segment_type_MemTableConsumption{background-color:var(--g-color-base-warning-medium-hover)}.memory-viewer__segment_type_QueryExecutionConsumption{background-color:var(--g-color-base-positive-medium-hover)}.memory-viewer__segment_type_Other{background-color:var(--g-color-base-generic-medium-hover)}.memory-viewer__name{padding-left:28px}.memory-viewer_theme_dark{color:var(--g-color-text-light-primary)}.memory-viewer_theme_dark .memory-viewer__segment{opacity:.75}.memory-viewer_status_good .memory-viewer__progress-container{background-color:var(--g-color-base-positive-light)}.memory-viewer_status_warning .memory-viewer__progress-container{background-color:var(--g-color-base-yellow-light)}.memory-viewer_status_danger .memory-viewer__progress-container{background-color:var(--g-color-base-danger-light)}.memory-viewer__text{align-items:center;display:flex;justify-content:center}.ydb-pool-bar{border:1px solid;border-radius:1px;cursor:pointer;height:20px;margin-right:2px;position:relative;width:6px}.ydb-pool-bar__popup-content{padding:10px;width:170px}.ydb-pool-bar:last-child{margin-right:0}.ydb-pool-bar_type_normal{border-color:var(--ydb-color-status-green)}.ydb-pool-bar_type_warning{border-color:var(--ydb-color-status-yellow)}.ydb-pool-bar_type_danger{border-color:var(--ydb-color-status-red)}.ydb-pool-bar__value{bottom:0;min-height:1px;position:absolute;width:100%}.ydb-pool-bar__value_type_normal{background-color:var(--ydb-color-status-green)}.ydb-pool-bar__value_type_warning{background-color:var(--ydb-color-status-yellow)}.ydb-pool-bar__value_type_danger{background-color:var(--ydb-color-status-red)}.ydb-pools-graph{display:flex}.tablets-statistic{align-items:center;display:flex;gap:2px}.tablets-statistic__tablet{border:1px solid;border-radius:2px;color:var(--g-color-text-secondary);display:inline-block;font-size:11px;height:20px;line-height:20px;padding:0 4px;text-align:center;text-decoration:none;text-transform:uppercase}.tablets-statistic__tablet_state_green{background-color:var(--g-color-base-positive-light);color:var(--g-color-text-positive)}.tablets-statistic__tablet_state_yellow{background-color:var(--g-color-base-warning-light);color:var(--g-color-text-warning)}.tablets-statistic__tablet_state_blue{background-color:var(--g-color-base-info-light);color:var(--g-color-text-info)}.tablets-statistic__tablet_state_orange{background-color:var(--g-color-base-warning-light);color:var(--g-color-text-warning-heavy)}.tablets-statistic__tablet_state_red{background:var(--g-color-base-danger-light);color:var(--g-color-text-danger)}.tablets-statistic__tablet_state_grey{border:1px solid var(--g-color-line-generic-hover);color:var(--g-color-text-secondary)}.ydb-nodes-columns__column-cpu,.ydb-nodes-columns__column-ram{min-width:40px}.storage-disk-progress-bar{--progress-bar-full-height:var(--g-text-body-3-line-height);--progress-bar-compact-height:12px;--entity-state-border-color:var(--g-color-base-misc-heavy);--entity-state-background-color:var(--g-color-base-misc-light);--entity-state-fill-color:var(--g-color-base-misc-medium);--entity-state-font-color:var(--g-color-text-primary);background-color:var(--entity-state-background-color);border:1px solid var(--entity-state-border-color);border-radius:4px;color:var(--g-color-text-primary);height:var(--progress-bar-full-height);min-width:50px;position:relative;text-align:center;z-index:0}.storage-disk-progress-bar_green{--entity-state-font-color:var(--g-color-text-positive);--entity-state-border-color:var(--g-color-base-positive-heavy);--entity-state-background-color:var(--g-color-base-positive-light);--entity-state-fill-color:var(--g-color-base-positive-medium)}.storage-disk-progress-bar_blue{--entity-state-font-color:var(--g-color-text-info);--entity-state-border-color:var(--g-color-base-info-heavy);--entity-state-background-color:var(--g-color-base-info-light);--entity-state-fill-color:var(--g-color-base-info-medium)}.storage-disk-progress-bar_yellow{--entity-state-font-color:var(--g-color-text-warning);--entity-state-border-color:var(--g-color-base-warning-heavy);--entity-state-background-color:var(--g-color-base-yellow-light);--entity-state-fill-color:var(--g-color-base-yellow-medium)}.storage-disk-progress-bar_orange{--entity-state-font-color:var(--g-color-private-orange-500);--entity-state-border-color:var(--ydb-color-status-orange);--entity-state-background-color:var(--g-color-private-orange-100);--entity-state-fill-color:var(--g-color-private-orange-300)}.storage-disk-progress-bar_red{--entity-state-font-color:var(--g-color-text-danger);--entity-state-border-color:var(--g-color-base-danger-heavy);--entity-state-background-color:var(--g-color-base-danger-light);--entity-state-fill-color:var(--g-color-base-danger-medium)}.storage-disk-progress-bar__grey{--entity-state-font-color:var(--g-color-text-secondary);--entity-state-border-color:var(--g-color-line-generic-hover)}.storage-disk-progress-bar_compact{border-radius:2px;height:var(--progress-bar-compact-height);min-width:0}.storage-disk-progress-bar_faded{background-color:unset}.storage-disk-progress-bar_inactive{opacity:.5}.storage-disk-progress-bar_empty{background-color:unset;border-style:dashed;color:var(--g-color-text-hint)}.storage-disk-progress-bar__fill-bar{background-color:var(--entity-state-fill-color);border-radius:3px 0 0 3px;height:100%;left:0;position:absolute;top:0}.storage-disk-progress-bar__fill-bar_faded{background-color:var(--entity-state-background-color)}.storage-disk-progress-bar__fill-bar_compact{border-radius:1px}.storage-disk-progress-bar__fill-bar_inverted{border-radius:0 3px 3px 0;left:auto;right:0}.storage-disk-progress-bar__title{color:inherit;font-size:var(--g-text-body-1-font-size);line-height:calc(var(--progress-bar-full-height) - 2px);position:relative;z-index:2}.vdisk-storage-popup .info-viewer+.info-viewer{border-top:1px solid var(--g-color-line-generic);margin-top:8px;padding-top:8px}.vdisk-storage-popup__donor-label{margin-bottom:8px}.ydb-vdisk-component{border-radius:4px}.ydb-vdisk-component__content{border-radius:4px;display:block}.pdisk-storage{--pdisk-vdisk-width:3px;--pdisk-gap-width:2px;display:flex;flex-direction:column;justify-content:flex-end;min-width:var(--pdisk-min-width);position:relative}.pdisk-storage__content{border-radius:4px;display:block;flex:1 1;position:relative}.pdisk-storage__vdisks{display:flex;flex:0 0 auto;gap:var(--pdisk-gap-width);margin-bottom:4px;white-space:nowrap}.pdisk-storage__vdisks-item{flex:0 0 var(--pdisk-vdisk-width);min-width:var(--pdisk-vdisk-width)}.data-table__row:hover .pdisk-storage__vdisks-item .stack__layer{background:var(--ydb-data-table-color-hover)}.pdisk-storage__donors-stack{--ydb-stack-offset-x:0px;--ydb-stack-offset-y:-2px;--ydb-stack-offset-x-hover:0px;--ydb-stack-offset-y-hover:-7px}.pdisk-storage__media-type{color:var(--g-color-text-secondary);font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height);position:absolute;right:4px;top:50%;transform:translateY(-50%)}.ydb-storage-disks{align-items:center;display:flex;flex-direction:row;gap:20px;width:max-content}.ydb-storage-disks__pdisks-wrapper{display:flex;flex-direction:row;justify-content:left;width:max-content}.ydb-storage-disks__vdisk-item{flex-basis:8px;flex-shrink:0}.ydb-storage-disks__vdisk-progress-bar{--progress-bar-compact-height:18px;border-radius:4px}.ydb-storage-disks__pdisk-item{margin-right:4px;min-width:80px}.ydb-storage-disks__pdisk-item_with-dc-margin{margin-right:12px}.ydb-storage-disks__pdisk-item:last-child{margin-right:0}.ydb-storage-disks__pdisk-progress-bar{--progress-bar-full-height:20px;padding-left:var(--g-spacing-2);text-align:left}.stack{--ydb-stack-base-z-index:100;--ydb-stack-offset-x:4px;--ydb-stack-offset-y:4px;--ydb-stack-offset-x-hover:4px;--ydb-stack-offset-y-hover:6px;position:relative}.stack__layer{background:var(--g-color-base-background);transition:transform .1s ease-out}.stack__layer:first-child{position:relative;z-index:var(--ydb-stack-base-z-index)}.stack__layer+.stack__layer{height:100%;left:0;position:absolute;top:0;transform:translate(calc(var(--ydb-stack-level)*var(--ydb-stack-offset-x)),calc(var(--ydb-stack-level)*var(--ydb-stack-offset-y)));width:100%;z-index:calc(var(--ydb-stack-base-z-index) - var(--ydb-stack-level))}.stack:hover .stack__layer:first-child{transform:translate(calc(var(--ydb-stack-offset-x-hover)*-1),calc(var(--ydb-stack-offset-y-hover)*-1))}.stack:hover .stack__layer+.stack__layer{transform:translate(calc(var(--ydb-stack-level)*var(--ydb-stack-offset-x-hover)*2 - var(--ydb-stack-offset-x-hover)),calc(var(--ydb-stack-level)*var(--ydb-stack-offset-y-hover)*2 - var(--ydb-stack-offset-y-hover)))}.ydb-storage-vdisks__wrapper{display:flex}.ydb-storage-vdisks__item{margin-right:6px;width:90px}.ydb-storage-vdisks__item_with-dc-margin{margin-right:12px}.ydb-storage-vdisks__item:last-child{margin-right:0}.data-table__row:hover .ydb-storage-vdisks__item .stack__layer{background:var(--ydb-data-table-color-hover)}.ydb-storage-groups-columns__disks-column,.ydb-storage-groups-columns__vdisks-column{overflow:visible}.ydb-storage-groups-columns__pool-name-wrapper{direction:rtl;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-storage-groups-columns__pool-name{unicode-bidi:plaintext}.ydb-storage-groups-columns__group-id{font-weight:500;margin-right:var(--g-spacing-1)}.global-storage__search{width:238px}.global-storage__table .g-tooltip{height:var(--g-text-body-2-line-height)!important}.global-storage .entity-status{justify-content:center}.ydb-storage-nodes__node_unavailable{opacity:.6}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-storage-nodes-columns__pdisks-column{overflow:visible}.ydb-storage-nodes-columns__pdisks-wrapper{display:flex;gap:10px;height:40px}.ydb-storage-nodes-columns__pdisks-item{display:flex;flex-shrink:0}.ydb-info-viewer-skeleton{display:flex;flex-direction:column;gap:16px}.ydb-info-viewer-skeleton__row{align-items:flex-start;display:flex}.ydb-info-viewer-skeleton__row,.ydb-info-viewer-skeleton__row .g-skeleton{min-height:var(--g-text-body-2-font-size)}.ydb-info-viewer-skeleton__label{align-items:baseline;display:flex;flex:0 1 auto;width:200px}.ydb-info-viewer-skeleton__label__text{width:100px}.ydb-info-viewer-skeleton__label__dots{border-bottom:1px dotted var(--g-color-text-secondary);margin:0 2px;width:100px}.ydb-info-viewer-skeleton__value{max-width:20%;min-width:200px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/3779.66c0ef83.chunk.css b/ydb/core/viewer/monitoring/static/css/3779.66c0ef83.chunk.css deleted file mode 100644 index 52bf4a675fc9..000000000000 --- a/ydb/core/viewer/monitoring/static/css/3779.66c0ef83.chunk.css +++ /dev/null @@ -1 +0,0 @@ -.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.ydb-resizeable-data-table{display:flex;padding-right:20px;width:max-content}.ydb-search{min-width:100px}.progress-viewer{align-items:center;background:var(--g-color-base-generic);border-radius:2px;color:var(--g-color-text-complementary);display:flex;font-size:var(--g-text-body-2-font-size);height:23px;justify-content:center;min-width:150px;overflow:hidden;padding:0 4px;position:relative;white-space:nowrap;z-index:0}.progress-viewer_theme_dark{color:var(--g-color-text-light-primary)}.progress-viewer_theme_dark .progress-viewer__line{opacity:.75}.progress-viewer_status_good{background-color:var(--g-color-base-positive-light)}.progress-viewer_status_good .progress-viewer__line{background-color:var(--ydb-color-status-green)}.progress-viewer_status_warning{background-color:var(--g-color-base-yellow-light)}.progress-viewer_status_warning .progress-viewer__line{background-color:var(--ydb-color-status-yellow)}.progress-viewer_status_danger{background-color:var(--g-color-base-danger-light)}.progress-viewer_status_danger .progress-viewer__line{background-color:var(--ydb-color-status-red)}.progress-viewer__line{height:100%;left:0;position:absolute;top:0}.progress-viewer__text{position:relative;z-index:1}.progress-viewer_size_xs{font-size:var(--g-text-body-2-font-size);height:20px;line-height:var(--g-text-body-2-line-height)}.progress-viewer_size_s{font-size:var(--g-text-body-1-font-size);height:28px;line-height:28px}.progress-viewer_size_m{font-size:var(--g-text-body-2-font-size);height:32px;line-height:32px}.progress-viewer_size_ns{font-size:13px;height:24px;line-height:var(--g-text-subheader-3-line-height)}.progress-viewer_size_n{font-size:var(--g-text-body-1-font-size);height:36px;line-height:36px}.progress-viewer_size_l{font-size:var(--g-text-subheader-3-font-size);height:38px;line-height:38px}.progress-viewer_size_head{font-size:var(--g-text-body-1-font-size);line-height:36px}.kv-user{color:var(--g-color-text-primary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.kv-user,.kv-user__name{display:inline-block}.kv-user__name:first-letter{color:var(--g-color-text-danger)}.gc-help-popover__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.gc-help-popover__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.g-progress{--_--empty-background-color:var(--g-color-base-generic);--_--empty-text-color:var(--g-color-text-primary);--_--filled-text-color:var(--g-color-text-primary);--_--filled-background-color:var(--g-color-base-neutral-medium);background-color:var(--g-progress-empty-background-color,var(--_--empty-background-color));border-radius:3px;margin:0 auto;overflow:hidden;position:relative;text-align:center}.g-progress__text{color:var(--g-progress-empty-text-color,var(--_--empty-text-color));position:relative}.g-progress__text,.g-progress__text-inner{box-sizing:border-box;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);padding:0 10px}.g-progress__text-inner{color:var(--g-progress-filled-text-color,var(--_--empty-text-color));height:100%;position:absolute;transition:transform .6s ease;width:100%}.g-progress__item{background-color:var(--g-progress-filled-background-color,var(--_--filled-background-color));float:left;height:100%;overflow:hidden;position:relative;transition:transform .6s ease,width .6s ease,background-color .6s ease;width:100%}[dir=rtl] .g-progress__item{float:right}.g-progress__item_theme_default{--_--filled-background-color:var(--g-color-base-neutral-medium)}.g-progress__item_theme_success{--_--filled-background-color:var(--g-color-base-positive-medium)}.g-progress__item_theme_warning{--_--filled-background-color:var(--g-color-base-warning-medium)}.g-progress__item_theme_danger{--_--filled-background-color:var(--g-color-base-danger-medium)}.g-progress__item_theme_info{--_--filled-background-color:var(--g-color-base-info-medium)}.g-progress__item_theme_misc{--_--filled-background-color:var(--g-color-base-misc-medium)}.g-progress__item_loading{animation:g-loading-animation .5s linear infinite;background-clip:padding-box;background-image:repeating-linear-gradient(-45deg,#ffffff4d,#ffffff4d 4px,#0000 0,#0000 8px);background-size:150%}.g-progress__stack{color:var(--g-color-text-light-primary);margin:0 auto;overflow:hidden;position:relative;transition:transform .6s ease;width:100%}.g-progress_size_m,.g-progress_size_m .g-progress__stack{height:20px;line-height:20px}.g-progress_size_m .g-progress__text{height:20px;margin-block-end:-20px}.g-progress_size_s,.g-progress_size_s .g-progress__stack{height:10px;line-height:10px}.g-progress_size_xs,.g-progress_size_xs .g-progress__stack{height:4px;line-height:4px}.g-progress_size_s .g-progress__text,.g-progress_size_s .g-progress__text-inner,.g-progress_size_xs .g-progress__text,.g-progress_size_xs .g-progress__text-inner{display:none}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.clusters{display:flex;flex:1 1 auto;flex-direction:column;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);overflow:auto;padding-top:15px}.clusters__autorefresh{margin-left:auto}.clusters__cluster{align-items:center;display:flex}.clusters__cluster-status{border-radius:3px;height:18px;margin-right:8px;width:18px}.clusters__cluster-status span{align-items:center;display:flex}.clusters__cluster-status_type_green{background-color:var(--ydb-color-status-green)}.clusters__cluster-status_type_yellow{background-color:var(--ydb-color-status-yellow)}.clusters__cluster-status_type_blue{background-color:var(--ydb-color-status-blue)}.clusters__cluster-status_type_red{background:var(--ydb-color-status-red)}.clusters__cluster-status_type_grey{background:var(--ydb-color-status-grey)}.clusters__cluster-status_type_orange{background:var(--ydb-color-status-orange)}.clusters__cluster-name{color:var(--g-color-text-link);text-decoration:none;white-space:normal}.clusters__cluster-versions{text-decoration:none}.clusters__cluster-version{overflow:hidden;text-overflow:ellipsis}.clusters__cluster-dc{white-space:normal}.clusters__controls{display:flex;margin-bottom:20px}.clusters__control{margin-right:15px;width:200px}.clusters__control_wide{width:300px}.clusters__empty-cell{color:var(--g-color-text-secondary)}.clusters__tooltip-content{word-break:break-all}.clusters .g-progress__item{transition:none}.clusters__aggregation,.clusters__controls{margin-left:15px;margin-right:15px}.clusters__aggregation{align-items:center;background:var(--g-color-base-generic-ultralight);border:1px solid var(--g-color-line-generic);border-radius:10px;display:flex;height:46px;margin-bottom:20px;padding:10px 20px;width:max-content}.clusters__aggregation-value-container{align-items:center;display:flex;font-size:var(--g-text-subheader-3-font-size);line-height:var(--g-text-subheader-3-line-height);max-width:230px}.clusters__aggregation-value-container:not(:last-child){margin-right:30px}.clusters__aggregation-label{color:var(--g-color-text-complementary);font-weight:200;margin-right:8px}.clusters__text{color:var(--g-color-text-primary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.clusters__text:first-letter{color:var(--g-color-text-danger)}.clusters__description{max-width:200px;white-space:pre-wrap}.clusters__table-wrapper{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto;padding-left:5px}.clusters__table-content{height:100%;overflow:auto}.clusters__table .data-table__head-row:first-child .data-table__th:first-child,.clusters__table .data-table__td:first-child{background-color:var(--g-color-base-background);border-right:1px solid var(--g-color-line-generic);left:0;position:sticky;z-index:2000}.clusters__table .data-table__row:hover .data-table__td:first-child{background-color:var(--ydb-data-table-color-hover)!important}.clusters__table .data-table__head-row:first-child .data-table__th:nth-child(0),.clusters__table .data-table__td:nth-child(0){border-right:unset;box-shadow:unset}.clusters__table .data-table__head-row:first-child .data-table__th:first-child,.clusters__table .data-table__td:first-child{box-shadow:unset}.clusters__balancer-cell{align-items:center;display:flex;flex-direction:row}.clusters__balancer-text{display:inline-block;margin-right:5px;max-width:92%;overflow:hidden;overflow-wrap:break-word!important;text-overflow:ellipsis}.clusters__balancer-icon{align-items:center;display:flex}.clusters__error{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin-left:15px}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/3812.440ff245.chunk.css b/ydb/core/viewer/monitoring/static/css/3812.440ff245.chunk.css deleted file mode 100644 index f71ded6bace8..000000000000 --- a/ydb/core/viewer/monitoring/static/css/3812.440ff245.chunk.css +++ /dev/null @@ -1 +0,0 @@ -.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-info-viewer-skeleton{display:flex;flex-direction:column;gap:16px}.ydb-info-viewer-skeleton__row{align-items:flex-start;display:flex}.ydb-info-viewer-skeleton__row,.ydb-info-viewer-skeleton__row .g-skeleton{min-height:var(--g-text-body-2-font-size)}.ydb-info-viewer-skeleton__label{align-items:baseline;display:flex;flex:0 1 auto;width:200px}.ydb-info-viewer-skeleton__label__text{width:100px}.ydb-info-viewer-skeleton__label__dots{border-bottom:1px dotted var(--g-color-text-secondary);margin:0 2px;width:100px}.ydb-info-viewer-skeleton__value{max-width:20%;min-width:200px}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-storage-group-page{height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-storage-group-page__info,.ydb-storage-group-page__meta,.ydb-storage-group-page__storage-title,.ydb-storage-group-page__title{left:0;margin-bottom:20px;position:sticky}.ydb-storage-group-page__meta{margin-top:20px}.ydb-storage-group-page__title{margin-bottom:60px}.ydb-storage-group-page__storage-title{font-size:var(--g-text-header-1-font-size);line-height:var(--g-text-header-1-line-height);margin-bottom:0}.ydb-storage-group-page__info{margin-top:var(--g-spacing-10)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/38527.5a5e407a.chunk.css b/ydb/core/viewer/monitoring/static/css/38527.5a5e407a.chunk.css new file mode 100644 index 000000000000..62bff7f76118 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/38527.5a5e407a.chunk.css @@ -0,0 +1 @@ +@charset "UTF-8";.kv-shorty-string__toggle{font-size:.85em;margin-left:1em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.ydb-pdisk-decommission-button__button,.ydb-pdisk-decommission-button__popup{width:160px}.ydb-vdisk-info__title{display:flex;flex-direction:row;gap:var(--g-spacing-2)}.ydb-pdisk-space-distribution .storage-disk-progress-bar{height:100%}.ydb-pdisk-space-distribution__pdisk-bar{display:flex;flex-direction:column;flex-grow:1;gap:var(--g-spacing-2);max-width:800px;min-width:500px;padding:var(--g-spacing-2)}.ydb-pdisk-space-distribution__slot-wrapper{background-color:var(--g-color-base-background);z-index:1}.ydb-pdisk-space-distribution__slot{display:flex;width:100%}.ydb-pdisk-space-distribution__slot-content{align-items:center;display:flex;flex-direction:row;flex-grow:1;justify-content:space-between;line-height:15px;padding:0 var(--g-spacing-2);z-index:1}.ydb-pdisk-space-distribution__slot-id{font-weight:600;margin-right:var(--g-spacing-3)}.ydb-pdisk-space-distribution__vdisk-popup{padding:var(--g-spacing-half) var(--g-spacing-2) var(--g-spacing-2)}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-pdisk-page{height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-pdisk-page__controls,.ydb-pdisk-page__info,.ydb-pdisk-page__meta,.ydb-pdisk-page__tabs,.ydb-pdisk-page__title{left:0;margin-bottom:20px;position:sticky}.ydb-pdisk-page__meta{margin-top:20px}.ydb-pdisk-page__tabs{margin-bottom:0}.ydb-pdisk-page__disk-distribution{padding:20px 0}.ydb-pdisk-page__title{flex-direction:row}.ydb-pdisk-page__controls,.ydb-pdisk-page__title{align-items:center;display:flex;gap:var(--g-spacing-2)}.ydb-pdisk-page__tabs{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/3940.0971684f.chunk.css b/ydb/core/viewer/monitoring/static/css/3940.0971684f.chunk.css deleted file mode 100644 index 720052b0ff13..000000000000 --- a/ydb/core/viewer/monitoring/static/css/3940.0971684f.chunk.css +++ /dev/null @@ -1 +0,0 @@ -.g-select{display:inline-block;max-width:100%}.g-select_width_max{width:100%}.g-select-filter{--g-text-input-border-color:var(--g-color-line-generic-active)}.g-select-list{display:flex;margin:4px 0;overflow:hidden}.g-popup .g-select-list:first-child,.g-popup .g-select-list:last-child{border-radius:0}.g-select-list:not(.g-select-list_virtualized){overflow:auto;position:relative}.g-select-list_mobile{max-height:100%}.g-select-list__group-label,.g-select-list__group-label-custom{box-sizing:border-box;height:auto;padding:0;position:relative;width:100%}.g-select-list__group-label{font-size:var(--g-text-body-1-font-size)}.g-select-list_size_s .g-select-list__group-label:not(.g-select-list__group-label_empty){height:24px;padding:8px 8px 4px}.g-select-list_size_m .g-select-list__group-label:not(.g-select-list__group-label_empty){height:28px;padding:8px 8px 4px}.g-select-list_size_l .g-select-list__group-label:not(.g-select-list__group-label_empty){height:36px;padding:10px 12px 6px}.g-select-list_size_xl .g-select-list__group-label:not(.g-select-list__group-label_empty){font-size:var(--g-text-body-2-font-size);height:44px;padding:12px 12px 8px}.g-select-list_mobile .g-select-list__group-label:not(.g-select-list__group-label_empty){font-size:var(--g-text-body-2-font-size);height:36px;padding:12px 12px 8px}.g-select-list__item:not(:first-child) .g-select-list__group-label{margin-block-start:5px}.g-select-list__item:not(:first-child) .g-select-list__group-label:before{background-color:var(--g-color-line-generic);content:"";height:1px;inset-block-start:-3px;inset-inline-start:0;position:absolute;width:100%}.g-select-list__group-label-content{font-weight:var(--g-text-accent-font-weight);overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:100%}.g-select-list__item.g-list__item_selected{background:none}.g-select-list__item.g-list__item_active,.g-select-list__item.g-list__item_selected:hover{background:var(--g-color-base-simple-hover)}.g-select-list__option{align-items:center;box-sizing:border-box;cursor:pointer;display:flex;height:100%;width:100%}.g-select-list_size_s .g-select-list__option{--_--select-tick-icon-padding-right:4px;padding:0 8px}.g-select-list_size_s .g-select-list__option .g-select-list__option-default-label{height:24px;line-height:24px}.g-select-list_size_m .g-select-list__option{--_--select-tick-icon-padding-right:4px;padding:0 8px}.g-select-list_size_m .g-select-list__option .g-select-list__option-default-label{height:28px;line-height:28px}.g-select-list_size_l .g-select-list__option{--_--select-tick-icon-padding-right:6px;padding:0 12px}.g-select-list_size_l .g-select-list__option .g-select-list__option-default-label{height:36px;line-height:36px}.g-select-list_size_xl .g-select-list__option{--_--select-tick-icon-padding-right:6px;padding:0 12px}.g-select-list_size_xl .g-select-list__option .g-select-list__option-default-label{font-size:var(--g-text-body-2-font-size);height:44px;line-height:44px}.g-select-list_mobile .g-select-list__option{padding:0 12px}.g-select-list_mobile .g-select-list__option .g-select-list__option-default-label{font-size:var(--g-text-body-2-font-size);height:36px;line-height:36px}.g-select-list_mobile .g-select-list__option .g-select-list__tick-icon{padding-inline-end:6px}.g-select-list__option_colored{background-color:var(--g-color-base-selection)}.g-select-list__option_disabled{cursor:default}.g-select-list__option-default-label{font-size:var(--g-text-body-1-font-size);overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:100%}.g-select-list__option-default-label_disabled{color:var(--g-color-text-secondary)}.g-select-list__tick-icon{box-sizing:initial;color:var(--g-color-text-brand);flex:0 0 16px;padding-inline-end:var(--_--select-tick-icon-padding-right);visibility:hidden}.g-select-list__tick-icon_shown{visibility:visible}.g-select-list__loading-indicator{align-items:center;display:flex;justify-content:center;width:100%}.g-select-empty-placeholder{color:var(--g-color-text-hint);margin:4px}.g-select-empty-placeholder_empty{margin-block-start:0}.g-select-counter{align-items:center;background-color:var(--g-color-base-generic);display:flex;justify-content:center;margin-inline:4px}.g-select-counter__text{flex-grow:1;margin-inline:4px;text-align:center}.g-select-counter_size_xl .g-select-counter__text{margin-inline:6px}.g-select-counter_size_s{border-radius:var(--g-border-radius-xs);height:20px;min-width:20px}.g-select-counter_size_m{border-radius:var(--g-border-radius-s);height:24px;min-width:24px}.g-select-counter_size_l{border-radius:var(--g-border-radius-m);height:28px;min-width:28px}.g-select-counter_size_xl{border-radius:var(--g-border-radius-l);height:36px;margin-inline:4px;min-width:36px}.g-select-clear{align-items:center;background:none;border:none;color:inherit;cursor:pointer;display:inline-flex;flex-shrink:0;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);justify-content:center;margin-inline-start:auto;outline:none;padding:0;z-index:1}.g-select-clear:focus-visible{border:1px solid var(--g-color-line-generic-active)}.g-select-clear_size_s{border-radius:var(--g-border-radius-s);height:24px;width:24px}.g-select-clear_size_m{border-radius:var(--g-border-radius-m);height:28px;width:28px}.g-select-clear_size_l{border-radius:var(--g-border-radius-l);height:36px;width:36px}.g-select-clear_size_xl{border-radius:var(--g-border-radius-xl);height:44px;width:44px}.g-select-clear__clear{color:var(--g-color-text-secondary)}.g-select-clear:hover .g-select-clear__clear{color:var(--g-color-text-primary)}.g-select-control{--_--focus-outline-color:var(--g-select-focus-outline-color);align-items:center;background:none;border:none;box-sizing:border-box;color:inherit;cursor:pointer;display:inline-flex;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;position:relative;transition:transform .1s ease-out;width:100%;z-index:0}.g-select-control_disabled{cursor:default}.g-select-control_size_s{--_--text-right-padding:8px;--_--border-radius:var(--g-border-radius-s);height:24px;padding:4px calc(var(--_--text-right-padding) + 1px)}.g-select-control_size_m{--_--text-right-padding:8px;--_--border-radius:var(--g-border-radius-m);height:28px;padding:6px calc(var(--_--text-right-padding) + 1px)}.g-select-control_size_l{--_--text-right-padding:12px;--_--border-radius:var(--g-border-radius-l);height:36px;padding:10px calc(var(--_--text-right-padding) + 1px)}.g-select-control_size_xl{--_--text-right-padding:12px;--_--border-radius:var(--g-border-radius-xl);height:44px;padding:12px calc(var(--_--text-right-padding) + 1px)}.g-select-control__button{align-items:center;background:none;border:none;color:inherit;cursor:pointer;display:inline-grid;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);grid-template-columns:auto auto;height:100%;justify-content:flex-start;outline:none;overflow:hidden;padding:0;transition:color .15s linear,background-color .15s linear;width:100%}.g-select-control__button.g-select-control__button_pin_round-round:before{border-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-brick:before{border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-clear:before{border-inline:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-circle:before{border-radius:100px}.g-select-control__button.g-select-control__button_pin_round-brick:before{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-round:before{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_round-clear:before{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_clear-round:before{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_brick-clear:before{border-inline-end:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-brick:before{border-inline-start:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-brick:before{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_brick-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_circle-clear:before{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_clear-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_round-round:after{border-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-brick:after{border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-clear:after{border-inline:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-circle:after{border-radius:100px}.g-select-control__button.g-select-control__button_pin_round-brick:after{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-round:after{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_round-clear:after{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_clear-round:after{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_brick-clear:after{border-inline-end:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-brick:after{border-inline-start:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-brick:after{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_brick-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_circle-clear:after{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_clear-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button:before{border:1px solid var(--g-color-line-generic);border-radius:var(--_--border-radius);content:"";inset:0;position:absolute}.g-select-control__button:after{content:"";inset:0;position:absolute;z-index:-1}.g-select-control__button_view_clear,.g-select-control__button_view_clear:after,.g-select-control__button_view_clear:before{border-color:#0000}.g-select-control__button_size_l,.g-select-control__button_size_m,.g-select-control__button_size_s{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-select-control__button_size_xl{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-select-control__button_error:before{--_--focus-outline-color:var(--g-color-line-danger);border-color:var(--g-color-line-danger)}.g-select-control__button:hover:after{background-color:var(--g-color-base-simple-hover)}.g-select-control__button_disabled{color:var(--g-color-text-hint);pointer-events:none}.g-select-control__button_disabled:after{background-color:var(--g-color-base-generic-accent-disabled)}.g-select-control__button_disabled:before{border-color:#0000}.g-select-control__button:not(.g-select-control__button_error):not(.g-select-control__button_disabled):not(.g-select-control__button_view_clear):hover:before{border-color:var(--g-color-line-generic-hover)}.g-select-control__button:not(.g-select-control__button_error):not(.g-select-control__button_view_clear):focus-visible:before,.g-select-control__button_open:not(.g-select-control__button_error):not(.g-select-control__button_view_clear):before{border-color:var(--g-color-line-generic-active)}.g-select-control__button:focus-visible:before{outline:2px solid var(--g-select-focus-outline-color,var(--_--focus-outline-color));outline-offset:-1px}.g-select-control:not(.g-select-control_disabled):not(.g-select-control_no-active):active{transform:scale(.96)}.g-select-control__label{font-weight:var(--g-text-accent-font-weight);margin-inline-end:4px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-select-control__option-text,.g-select-control__placeholder{overflow:hidden;padding-inline-end:var(--_--text-right-padding);text-overflow:ellipsis;white-space:nowrap}.g-select-control_has-clear.g-select-control_size_s .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(24px + var(--_--text-right-padding))}.g-select-control_has-clear.g-select-control_size_m .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(28px + var(--_--text-right-padding))}.g-select-control_has-clear.g-select-control_size_l .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(36px + var(--_--text-right-padding))}.g-select-control_has-clear.g-select-control_size_xl .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(44px + var(--_--text-right-padding))}.g-select-control__placeholder{color:var(--g-color-text-hint)}.g-select-control__chevron-icon{color:var(--g-color-text-secondary);flex:0 0 16px;margin-inline-start:auto}.g-select-control__chevron-icon_disabled{color:var(--g-color-text-hint)}.g-select-clear+.g-select-control__chevron-icon{margin-inline-start:0}.g-select-control__error-icon{background:none;border:none;border-radius:var(--g-focus-border-radius);box-sizing:initial;color:inherit;color:var(--g-color-text-danger);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;padding:var(--_--text-input-error-icon-padding)}.g-select-control__error-icon:focus{outline:2px solid var(--g-color-line-focus)}.g-select-control__error-icon:focus:not(:focus-visible){outline:0}.g-select-popup{display:flex;flex-direction:column;max-height:90vh}.g-sheet{position:fixed;z-index:100000}.g-sheet,.g-sheet__veil{height:100%;inset-block-start:0;inset-inline-start:0;width:100%}.g-sheet__veil{background-color:var(--g-color-sfx-veil);opacity:0;position:absolute;will-change:opacity}.g-sheet__veil_with-transition{transition:opacity .3s ease}.g-sheet__sheet{inset-block-start:100%;inset-inline-start:0;max-height:90%;position:absolute;width:100%;will-change:transform}.g-sheet__sheet_with-transition{transition:transform .3s ease}.g-sheet__sheet-swipe-area{height:40px;inset-block-start:-20px;inset-inline-start:0;position:absolute;width:100%;z-index:1}.g-sheet__sheet-top{background-color:var(--g-color-base-float);border-start-end-radius:20px;border-start-start-radius:20px;height:20px;position:relative}.g-sheet__sheet-top-resizer{--_--translate-x:calc(-50%*var(--g-flow-direction));background-color:var(--g-color-line-generic);border-radius:4px;height:4px;inset-block-start:50%;inset-inline-start:50%;position:absolute;transform:translateX(var(--_--translate-x)) translateY(-50%);width:40px}.g-sheet__sheet-scroll-container{background-color:var(--g-color-base-float);box-sizing:border-box;max-height:calc(90% - 20px);overflow:hidden auto;overscroll-behavior-y:contain;transition:height .3s ease}.g-sheet__sheet-scroll-container_without-scroll{overflow:hidden}.g-sheet__sheet-content-box{border:1px solid #0000}.g-sheet__sheet-content-box-border-compensation{margin:-1px}.g-sheet__sheet-content{box-sizing:border-box;padding:var(--g-sheet-content-padding,0 10px);width:100%}.g-sheet__sheet-content-title{font-size:var(--g-text-body-2-font-size);line-height:28px;overflow:hidden;padding-block-end:8px;text-align:center;text-overflow:ellipsis;white-space:nowrap} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/4187.cac9847e.chunk.css b/ydb/core/viewer/monitoring/static/css/4187.cac9847e.chunk.css deleted file mode 100644 index 25326810c806..000000000000 --- a/ydb/core/viewer/monitoring/static/css/4187.cac9847e.chunk.css +++ /dev/null @@ -1 +0,0 @@ -.kv-split{display:flex;height:100%;outline:none;-webkit-user-select:text;user-select:text;z-index:0}.kv-split.horizontal{flex-direction:row}.kv-split.vertical{flex-direction:column;min-height:100%;width:100%}.kv-split .gutter{background:var(--g-color-base-background);position:relative;z-index:10}.kv-split .gutter:after{background-color:var(--g-color-base-generic-ultralight);content:"";inset:0;position:absolute}.kv-split .gutter.active:after,.kv-split .gutter:hover:after{background-color:var(--g-color-line-generic-hover);transition:background-color 1s ease}.kv-split .gutter.disabled{display:none}.kv-split .gutter.gutter-vertical{cursor:row-resize;height:8px;width:100%}.kv-split .gutter.gutter-vertical:before{border-color:var(--g-color-base-generic-hover);border-style:solid;border-width:1px 0;content:"";height:4px;left:50%;position:absolute;top:50%;transform:translate(-50%,-50%);width:16px}.kv-split .gutter.gutter-horizontal{cursor:col-resize;height:100%;width:8px}.kv-split .gutter.gutter-horizontal:before{border-color:var(--g-color-base-generic-hover);border-style:solid;border-width:0 1px;content:"";height:16px;left:50%;position:absolute;top:50%;transform:translate(-50%,-50%);width:4px}.histogram{display:flex;flex:1 1 auto}.histogram__chart{align-items:baseline;border-bottom:1px solid var(--g-color-base-generic);border-left:1px solid var(--g-color-base-generic);display:flex;height:300px;margin-left:50px;margin-top:30px;position:relative;width:800px}.histogram__x-min{left:-3px}.histogram__x-max,.histogram__x-min{bottom:-25px;color:var(--g-color-text-secondary);position:absolute}.histogram__x-max{right:0}.histogram__y-min{bottom:-7px;left:-30px;width:20px}.histogram__y-max,.histogram__y-min{color:var(--g-color-text-secondary);position:absolute;text-align:right}.histogram__y-max{left:-60px;top:-5px;width:50px}.histogram__item{cursor:pointer;margin-right:.5%;width:1.5%}.heatmap{display:flex;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto}.heatmap__limits{align-items:center;display:flex;margin-left:20px}.heatmap__limits-block{display:flex;margin-right:10px}.heatmap__limits-title{color:var(--g-color-text-secondary);margin-right:5px}.heatmap__row{align-items:center}.heatmap__row_overall{margin:15px 20px}.heatmap__row_overall .g-progress{margin:0;width:300px}.heatmap__label{font-size:var(--g-text-body-2-font-size);font-weight:500;line-height:var(--g-text-body-2-line-height);margin-right:16px;text-transform:uppercase}.heatmap__label_overall{margin-right:15px}.heatmap__items{overflow:auto}.heatmap__canvas-container{cursor:pointer;overflow:auto}.heatmap__filters{align-items:center;display:flex;margin:0 0 10px}.heatmap__filter-control{margin-right:10px;max-width:200px;min-width:100px}.heatmap__filter-control:last-child{margin-right:0}.heatmap__histogram-checkbox,.heatmap__sort-checkbox{margin-left:10px}.heatmap__row{display:flex}.heatmap .tablet,.heatmap__row{margin-bottom:2px}.ydb-nodes__search{width:238px}.ydb-nodes__show-all-wrapper{left:0;margin-bottom:15px;position:sticky}.ydb-nodes__node_unavailable{opacity:.6}.ydb-nodes__groups-wrapper{padding-right:20px}.ydb-resizeable-data-table{display:flex;padding-right:20px;width:max-content}.operations__search{width:220px}.kv-shorty-string__toggle{font-size:.85em;margin-left:2em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.schema-viewer__keys{display:inline-block;padding-bottom:var(--g-spacing-4);padding-left:10px}.schema-viewer__keys-values{color:var(--g-color-text-complementary);display:inline;font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height)}.schema-viewer__keys-header{color:var(--g-color-text-primary);display:inline;font-size:var(--g-text-subheader-1-font-size);font-weight:700;line-height:var(--g-text-subheader-1-line-height);white-space:nowrap}.schema-viewer__keys-label{cursor:pointer}.schema-viewer__keys-wrapper{left:0;position:sticky;width:100%;z-index:1}.schema-viewer__keys+.schema-viewer__keys{margin-left:var(--g-spacing-8)}.schema-viewer__keys_summary+.schema-viewer__keys_summary{margin-left:0}.schema-viewer__popup-content{padding:var(--g-spacing-2) var(--g-spacing-4)}.schema-viewer__popup-item{padding-bottom:var(--g-spacing-2)}.schema-viewer__popup-item:last-child{padding-bottom:0}.schema-viewer__more-badge{margin-left:var(--g-spacing-1)}.ydb-diagnostics-configs__icon-touched{color:var(--g-color-text-secondary);cursor:default!important;line-height:1}.speed-multimeter{display:flex;width:100%}.speed-multimeter__content{display:flex;flex-direction:row;flex-grow:1;justify-content:flex-end;line-height:22px}.speed-multimeter__displayed-value{display:flex;flex-direction:row;justify-content:flex-end;margin-right:10px}.speed-multimeter__bars{align-items:flex-start;display:flex;flex-direction:column;margin-right:5px;overflow:hidden;width:32px}.speed-multimeter__bar-container{height:6px;width:100%}.speed-multimeter__bar-container_highlighted{background:var(--g-color-line-generic)}.speed-multimeter__bar{height:100%;min-width:2px}.speed-multimeter__bar_color_light{background:var(--g-color-base-info-medium)}.speed-multimeter__bar_color_dark{background:var(--g-color-base-info-heavy)}.speed-multimeter__bar-container+.speed-multimeter__bar-container{margin-top:2px}.speed-multimeter__popover-container{align-items:center;display:flex;justify-content:center}.speed-multimeter__popover-content{padding:10px}.speed-multimeter__popover-header{display:block;font-size:18px;line-height:24px;margin-bottom:7px}.speed-multimeter__popover-row{display:block;font-size:13px;line-height:18px}.speed-multimeter__popover-row_color_primary{color:var(--g-color-text-primary)}.speed-multimeter__popover-row_color_secondary{color:var(--g-color-text-secondary)}.ydb-diagnostics-consumers-topic-stats{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-diagnostics-consumers-topic-stats__wrapper{border-left:1px solid var(--g-color-line-generic);display:flex;flex-direction:row;padding-left:16px}.ydb-diagnostics-consumers-topic-stats__item{display:flex;flex-direction:column;margin-right:20px}.ydb-diagnostics-consumers-topic-stats__label{color:var(--g-color-text-secondary);margin-bottom:4px}.ydb-diagnostics-consumers-topic-stats__value{align-items:center;display:flex;height:30px;justify-content:flex-start}.ydb-lag-popover-content__text{margin-bottom:10px}.ydb-lag-popover-content_type_read{max-width:280px}.ydb-lag-popover-content_type_write{max-width:220px}.ydb-diagnostics-consumers-columns-header__lags{white-space:nowrap}.ydb-diagnostics-consumers-columns__lags-header{text-align:center}.ydb-diagnostics-consumers{display:flex;flex-grow:1;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto}.ydb-diagnostics-consumers__controls{align-items:center;display:flex;gap:12px;padding:16px 0 18px}.ydb-diagnostics-consumers__search{width:238px}.ydb-diagnostics-consumers__table-wrapper{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.ydb-diagnostics-consumers__table-content{height:100%;overflow:auto}.ydb-diagnostics-consumers__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-consumers__table .data-table__td:first-child{background-color:var(--g-color-base-background);border-right:1px solid var(--g-color-line-generic);left:0;position:sticky;z-index:2000}.ydb-diagnostics-consumers__table .data-table__row:hover .data-table__td:first-child{background-color:var(--ydb-data-table-color-hover)!important}.ydb-diagnostics-consumers__table .data-table__head-row:first-child .data-table__th:nth-child(0),.ydb-diagnostics-consumers__table .data-table__td:nth-child(0){border-right:unset;box-shadow:unset}.ydb-diagnostics-consumers__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-consumers__table .data-table__td:first-child{box-shadow:unset}.ydb-json-tree{height:100%;position:relative;width:100%}.ydb-json-tree__tree{word-wrap:break-word;font-family:var(--g-font-family-monospace)!important;font-size:var(--g-text-code-1-font-size)!important;line-height:var(--g-text-code-1-line-height)!important;width:100%}.ydb-json-tree__tree .json-inspector__leaf_composite:before{color:var(--g-color-text-secondary);font-size:9px;left:20px;position:absolute}.ydb-json-tree__tree .json-inspector__leaf_composite.json-inspector__leaf_root:before{left:0}.ydb-json-tree__tree :not(.json-inspector__leaf_expanded).json-inspector__leaf_composite:before{content:"[+]"}.ydb-json-tree__tree .json-inspector__leaf_expanded.json-inspector__leaf_composite:before{content:"[-]"}.ydb-json-tree__tree .json-inspector__key{color:var(--g-color-text-misc)}.ydb-json-tree__tree .json-inspector__leaf{padding-left:20px;position:relative}.ydb-json-tree__tree .json-inspector__leaf_root{padding-left:0}.ydb-json-tree__tree .json-inspector__line{padding-left:20px}.ydb-json-tree__tree .json-inspector__toolbar{border:1px solid var(--g-color-line-generic);border-radius:4px;margin-bottom:10px;width:300px}.ydb-json-tree__tree .json-inspector__search{background:none;border:0 solid #0000;border-width:0 22px 0 8px;box-sizing:border-box;color:var(--g-color-text-primary);font-family:var(--g-text-body-font-family);font-size:13px;height:28px;margin:0;outline:0;padding:0;vertical-align:top;width:300px}.ydb-json-tree__tree .json-inspector__value_helper{color:var(--g-color-text-secondary)}.ydb-json-tree__tree .json-inspector__line:hover:after{background:var(--g-color-base-simple-hover)}.ydb-json-tree__tree .json-inspector__show-original:before{color:var(--g-color-text-secondary)}.ydb-json-tree__tree .json-inspector__show-original:hover:after,.ydb-json-tree__tree .json-inspector__show-original:hover:before{color:var(--g-color-text-primary)}.ydb-json-tree__tree .json-inspector__leaf.json-inspector__leaf_root.json-inspector__leaf_composite{max-width:calc(100% - 50px)}.ydb-json-tree__case{left:308px;position:absolute;top:0}.ydb-json-tree .json-inspector__search{height:26px}.ydb-describe__message-container{padding:15px 0}.ydb-describe__result{display:flex;flex:0 0 auto;overflow:auto;padding:0 20px 20px 0;position:relative}.ydb-describe__copy{left:340px;position:absolute}.ydb-external-data-source-info__location,.ydb-external-table-info__location{max-width:var(--tenant-object-info-max-value-width)}.ydb-definition-list{display:flex;flex:1 1 auto;flex-direction:column}.ydb-definition-list__title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-definition-list__properties-list{max-width:calc(100% - 40px)}.ydb-async-replication-paths__title,.ydb-overview-topic-stats__title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-overview-topic-stats .ydb-loader{margin-top:50px}.ydb-overview-topic-stats .info-viewer__row{align-items:flex-start}.ydb-overview-topic-stats .speed-multimeter{margin-top:-5px}.ydb-overview-topic-stats .speed-multimeter__content{justify-content:flex-start}.ydb-overview-topic-stats__info .info-viewer__label-text_multiline{max-width:150px}.ydb-overview-topic-stats__bytes-written{margin-top:7px;padding-left:20px}.ydb-overview-topic-stats__bytes-written .info-viewer__label{min-width:180px}.ydb-diagnostics-table-info__title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-diagnostics-table-info__row{align-items:flex-start;display:flex;flex-wrap:wrap;justify-content:flex-start}.ydb-diagnostics-table-info__col{align-items:flex-start;display:flex;flex-direction:column;justify-content:flex-start}.ydb-diagnostics-table-info__col:not(:last-child){margin-right:50px}.ydb-diagnostics-table-info__info-block{margin-bottom:20px}.ydb-diagnostics-table-info__info-block .info-viewer__items{grid-template-columns:minmax(max-content,280px)}.ydb-metric-chart{border:1px solid var(--g-color-line-generic);border-radius:8px;display:flex;flex-direction:column;padding:16px 16px 8px}.ydb-metric-chart__title{margin-bottom:10px}.ydb-metric-chart__chart{display:flex;height:100%;overflow:hidden;position:relative;width:100%}.ydb-metric-chart__error{left:50%;position:absolute;text-align:center;top:10%;transform:translateX(-50%);z-index:1}.ydb-timeframe-selector{display:flex;gap:2px}.ydb-tenant-dashboard{margin-bottom:var(--diagnostics-section-margin);width:var(--diagnostics-section-table-width)}.ydb-tenant-dashboard__controls{margin-bottom:10px}.ydb-tenant-dashboard__charts{display:flex;flex-flow:row wrap;gap:16px}.issue-tree-item{align-items:center;cursor:pointer;display:flex;height:40px;justify-content:space-between}.issue-tree-item__field{display:flex;overflow:hidden}.issue-tree-item__field_status{display:flex;white-space:nowrap}.issue-tree-item__field_additional{color:var(--g-color-text-link);cursor:pointer;width:max-content}.issue-tree-item__field_additional:hover{color:var(--g-color-text-link-hover)}.issue-tree-item__field_message{flex-shrink:0;overflow:hidden;white-space:normal;width:300px}.issue-tree-item__field-tooltip.issue-tree-item__field-tooltip{max-width:500px;min-width:500px}.issue-tree-item__field-label{color:var(--g-color-text-secondary)}.issue-tree{display:flex}.issue-tree__block{width:100%}.issue-tree__checkbox{margin:5px 0 10px}.issue-tree__info-panel{background:var(--g-color-base-generic);border-radius:4px;height:100%;margin:11px 0;padding:8px 20px;position:sticky}.issue-tree__inspector .json-inspector__leaf_expanded.json-inspector__leaf_composite:before,.issue-tree__inspector :not(.json-inspector__leaf_expanded).json-inspector__leaf_composite:before{content:""}.issue-tree__inspector .json-inspector__line:hover:after{background:#0000}.issue-tree__inspector .json-inspector__show-original:hover:after,.issue-tree__inspector .json-inspector__show-original:hover:before{color:#0000}.issue-tree__inspector .json-inspector__value_helper{display:none}.issue-tree__inspector .json-inspector__value{overflow:hidden;word-break:break-all}.issue-tree__inspector .json-inspector__value>span{-webkit-user-select:all;user-select:all}.issue-tree .ydb-tree-view__item{height:40px}.issue-tree .ydb-tree-view .tree-view_arrow{height:40px;width:40px}.issue-tree .ydb-tree-view .ydb-tree-view__item{margin-left:calc(24px*var(--ydb-tree-view-level))!important;padding-left:0!important}.issue-tree .ydb-tree-view .issue-tree__info-panel{margin-left:calc(24px*var(--ydb-tree-view-level))}.healthcheck__details{width:872px}.healthcheck__details-content-wrapper{overflow-x:hidden}.healthcheck__preview{display:flex;flex-direction:column;height:100%}.healthcheck__preview-title{color:var(--g-color-text-link);font-size:var(--g-text-subheader-3-font-size);font-weight:600;line-height:var(--g-text-subheader-3-line-height)}.healthcheck__preview-content{line-height:24px;margin:auto}.healthcheck__preview-status-icon{height:64px;width:64px}.healthcheck__preview-title-wrapper{align-items:center;display:flex;gap:8px;margin-bottom:4px}.healthcheck__preview-issue{align-items:center;display:flex;flex-direction:column;gap:4px;position:relative;top:-8px}.healthcheck__preview-issue_good{color:var(--g-color-text-positive)}.healthcheck__preview-issue_good .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-positive-light)}.healthcheck__preview-issue_degraded{color:var(--g-color-text-info)}.healthcheck__preview-issue_degraded .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-info-light)}.healthcheck__preview-issue_emergency{color:var(--g-color-text-danger)}.healthcheck__preview-issue_emergency .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-danger-light)}.healthcheck__preview-issue_unspecified{color:var(--g-color-text-misc)}.healthcheck__preview-issue_unspecified .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-misc-light)}.healthcheck__preview-issue_maintenance_required{color:var(--g-color-text-warning-heavy)}.healthcheck__preview-issue_maintenance_required .healthcheck__self-check-status-indicator{background-color:var(--g-color-base-warning-light)}.healthcheck__self-check-status-indicator{text-wrap:nowrap;border-radius:4px;display:inline-block;font-size:13px;line-height:24px;padding:0 8px}.healthcheck__icon-warn{color:var(--g-color-text-warning)}.healthcheck__icon-wrapper{display:flex}.ydb-diagnostic-card{background-color:#0000;border:1px solid var(--g-color-line-generic);border-radius:8px;flex-shrink:0;padding:16px 16px 28px}.ydb-diagnostic-card_active{background-color:var(--g-color-base-selection);border-color:var(--g-color-base-info-medium)}.ydb-diagnostic-card_interactive:hover{box-shadow:0 1px 5px var(--g-color-sfx-shadow);cursor:pointer}.ydb-diagnostic-card_size_m{min-width:206px;width:206px}.ydb-diagnostic-card_size_l{min-width:289px;width:289px}.ydb-diagnostic-card_size_s{min-width:134px;width:134px}.ydb-metrics-card{min-height:252px}.ydb-metrics-card__header{align-items:center;display:flex;gap:8px;justify-content:space-between;margin-bottom:10px}.ydb-metrics-card__label{color:var(--g-color-text-link);font-size:var(--g-text-subheader-3-font-size);font-weight:600;line-height:var(--g-text-subheader-3-line-height)}.ydb-metrics-card__content{color:var(--g-color-text-secondary);display:flex;flex-direction:column;gap:10px}.ydb-metrics-card__metric-title{height:var(--g-text-body-2-line-height)}.ydb-metrics-card_active .ydb-metrics-card__content{color:var(--g-color-text-complementary)}.metrics-cards{display:flex;gap:16px;margin-bottom:32px}.metrics-cards__tab{color:inherit;text-decoration:none}.confirmation-dialog__caption,.confirmation-dialog__message{white-space:pre-wrap}.ydb-save-query__dialog-row{align-items:flex-start;display:flex}.ydb-save-query__dialog-row+.ydb-save-query__dialog-row{margin-top:var(--g-text-body-1-line-height)}.ydb-save-query__field-title{font-weight:500;line-height:28px;margin-right:12px;white-space:nowrap}.ydb-save-query__field-title.required:after{color:var(--g-color-text-danger);content:"*"}.ydb-save-query__control-wrapper{display:flex;flex-grow:1;min-height:48px}.kv-truncated-query{max-width:100%;vertical-align:top;white-space:pre;word-break:break-word}.kv-truncated-query__message{white-space:pre-wrap}.kv-truncated-query__message_color_secondary{color:var(--g-color-text-secondary)}.kv-top-queries{display:flex;flex-direction:column;height:100%}.kv-top-queries .data-table__box .data-table__table-wrapper{padding-bottom:20px}.kv-top-queries .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.kv-top-queries__search{width:238px}.kv-top-queries__row{cursor:pointer}.kv-top-queries__query{overflow:hidden;text-overflow:ellipsis;vertical-align:top;white-space:pre-wrap;word-break:break-word}.kv-top-queries__user-sid{max-width:200px;overflow:hidden;text-overflow:ellipsis}.tenant-overview{height:100%;overflow:auto;padding-bottom:20px}.tenant-overview__loader{display:flex;justify-content:center}.tenant-overview__tenant-name-wrapper{align-items:center;display:flex;overflow:hidden}.tenant-overview__top{align-items:center;display:flex;gap:4px;line-height:24px;margin-bottom:10px}.tenant-overview__top-label{font-weight:600;gap:10px;line-height:24px;margin-bottom:var(--diagnostics-section-title-margin)}.tenant-overview__info{left:0;position:sticky;width:max-content}.tenant-overview__title{font-size:var(--g-text-body-2-font-size);font-weight:700;line-height:var(--g-text-body-2-line-height);margin-bottom:10px}.tenant-overview__table:not(:last-child){margin-bottom:var(--diagnostics-section-margin)}.tenant-overview__top-queries-row{cursor:pointer}.tenant-overview__storage-info{margin-bottom:36px}.tenant-overview__memory-info{margin-bottom:36px;width:300px}.kv-detailed-overview{display:flex;flex-direction:column;gap:20px;height:100%;width:100%}.kv-detailed-overview__section{display:flex;flex-basis:calc(50% - 10px);flex-direction:column;flex-grow:1;flex-shrink:0;min-width:300px}.kv-detailed-overview__modal .g-modal__content{position:relative}.kv-detailed-overview__close-modal-button{position:absolute;right:13px;top:23px}.ydb-hot-keys__primary-key-column{align-items:center;display:flex;gap:5px}.ydb-hot-keys__help-card{left:0;margin-bottom:20px;padding:20px 40px 20px 20px;position:sticky}.ydb-hot-keys__help-card__close-button{position:absolute;right:5px;top:5px}.node-network{border:1px solid #0000;border-radius:4px;box-sizing:border-box;color:var(--g-color-text-complementary);cursor:pointer;display:inline-block;font-size:12px;height:14px;line-height:14px;margin-bottom:5px;margin-right:5px;padding:0 5px;text-align:center;text-transform:uppercase;width:14px}.node-network_id{height:14px;width:42px}.node-network_blur{opacity:.25}.node-network_grey{background:var(--ydb-color-status-grey)}.node-network_black{background-color:var(--ydb-color-status-black);color:var(--g-color-text-light-primary)}.node-network_green{background-color:var(--ydb-color-status-green)}.node-network_yellow{background-color:var(--ydb-color-status-yellow)}.node-network_red{background-color:var(--ydb-color-status-red)}.node-network:hover{border:1px solid var(--g-color-text-primary)}.network{flex-direction:column;font-size:var(--g-text-body-2-font-size);justify-content:space-between;line-height:var(--g-text-body-2-line-height);max-width:1305px}.network,.network__nodes-row{display:flex;flex-grow:1;height:100%;overflow:auto}.network__nodes-row{align-items:flex-start;flex-direction:row}.network__inner{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.network__right{height:100%;padding-left:20px;width:100%}.network__left{border-right:1px solid var(--g-color-base-generic-accent);height:100%}.network__placeholder{align-items:center;display:flex;flex-direction:column;flex-grow:1;height:100%;justify-content:center;width:100%}.network__placeholder-text{margin-top:15px}.network__placeholder-img{color:#0000}.network__nodes{display:flex;flex-wrap:wrap}.network__nodes-container{min-width:325px}.network__nodes-container_right{margin-right:60px}.network__nodes-title{border-bottom:1px solid var(--g-color-base-generic-accent);color:var(--g-color-text-secondary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin:0 0 15px}.network__link{color:var(--g-color-base-brand);text-decoration:none}.network__title{font-size:var(--g-text-body-1-font-size);font-weight:500;line-height:var(--g-text-body-1-line-height);margin:20px 0}.network__checkbox-wrapper{align-items:center;display:flex}.network__checkbox-wrapper label{white-space:nowrap}.network__label{margin-bottom:16px}.network__controls{display:flex;gap:12px;margin:0 16px 16px 0}.network__controls-wrapper{display:flex;flex:1 1 auto;flex-direction:row;flex-direction:column}.network__select{margin:0 15px;max-width:115px}.network__rack-column{align-items:center;background-color:#00000012;border-radius:4px;display:flex;flex-direction:column;margin-bottom:5px;margin-right:5px;padding:2px}.network__rack-column .node-network{margin-right:0}.ydb-diagnostics-partitions-columns-header__multiline{white-space:normal}.ydb-diagnostics-partitions-columns-header__read-session{white-space:normal;width:80px}.ydb-diagnostics-partitions-columns-header__lags{white-space:nowrap}.ydb-diagnostics-partitions-columns-header__messages{white-space:normal;width:90px}.ydb-diagnostics-partitions-columns-header__messages-popover-content{max-width:200px}.ydb-diagnostics-partitions-columns__lags-header{text-align:center}.ydb-diagnostics-partitions{display:flex;flex-grow:1;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto}.ydb-diagnostics-partitions__controls{align-items:center;display:flex;gap:12px;padding:16px 0 18px}.ydb-diagnostics-partitions__consumer-select{width:220px}.ydb-diagnostics-partitions__select-option_empty{color:var(--g-color-text-hint)}.ydb-diagnostics-partitions__search{width:238px}.ydb-diagnostics-partitions__search_partition{width:100px}.ydb-diagnostics-partitions__search_general{width:280px}.ydb-diagnostics-partitions__table-wrapper{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.ydb-diagnostics-partitions__table-content{height:100%;overflow:auto}.ydb-diagnostics-partitions__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-partitions__table .data-table__td:first-child{background-color:var(--g-color-base-background);border-right:1px solid var(--g-color-line-generic);left:0;position:sticky;z-index:2000}.ydb-diagnostics-partitions__table .data-table__row:hover .data-table__td:first-child{background-color:var(--ydb-data-table-color-hover)!important}.ydb-diagnostics-partitions__table .data-table__head-row:first-child .data-table__th:nth-child(0),.ydb-diagnostics-partitions__table .data-table__td:nth-child(0){border-right:unset;box-shadow:unset}.ydb-diagnostics-partitions__table .data-table__head-row:first-child .data-table__th:first-child,.ydb-diagnostics-partitions__table .data-table__td:first-child{box-shadow:unset}.date-range__range-input_s{width:200px}.date-range__range-input_m{width:300px}.date-range__range-input_l{width:350px}.date-range__range-input input{cursor:pointer}.top-shards__hint{left:0;position:sticky;width:max-content}.kv-tenant-diagnostics{display:flex;flex-direction:column;height:100%;overflow:hidden}.kv-tenant-diagnostics__header-wrapper{background-color:var(--g-color-base-background);padding:0 20px 16px}.kv-tenant-diagnostics__tabs{--g-tabs-border-width:0;align-items:center;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic);display:flex;justify-content:space-between}.kv-tenant-diagnostics__tabs .g-tabs_direction_horizontal{box-shadow:unset}.kv-tenant-diagnostics__tab{margin-right:40px;text-decoration:none}.kv-tenant-diagnostics__tab:first-letter{text-transform:uppercase}.kv-tenant-diagnostics__page-wrapper{flex-grow:1;overflow:auto;padding:0 20px;width:100%}.kv-tenant-diagnostics__page-wrapper .ydb-table-with-controls-layout__controls{height:46px;padding-top:0}.kv-tenant-diagnostics__page-wrapper .ydb-table-with-controls-layout .data-table__sticky_moving,.kv-tenant-diagnostics__page-wrapper .ydb-table-with-controls-layout .ydb-paginated-table__head{top:46px!important}.ydb-queries-history{display:flex;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto;padding:0 20px}.ydb-queries-history .ydb-table-with-controls-layout__controls{height:46px;padding-top:0}.ydb-queries-history.ydb-table-with-controls-layout .data-table__sticky_moving{top:46px!important}.ydb-queries-history__search{width:238px}.ydb-queries-history__table-row{cursor:pointer}.ydb-queries-history__query{flex-grow:1;overflow:hidden;text-overflow:ellipsis;white-space:pre}.kv-pane-visibility-button_hidden{display:none}.kv-pane-visibility-button_bottom{transform:rotate(180deg)}.kv-pane-visibility-button_bottom.rotate{transform:rotate(0)}.kv-pane-visibility-button_left{transform:rotate(-90deg)}.kv-pane-visibility-button_left.rotate{transform:rotate(90deg)}.kv-pane-visibility-button_top.rotate{transform:rotate(180deg)}.ydb-fullscreen{flex-grow:1;overflow:hidden}.ydb-fullscreen_fullscreen{background-color:var(--g-color-base-background);inset:0;position:absolute;z-index:10}.ydb-fullscreen__close-button{display:none;position:fixed;right:20px;top:8px;z-index:11}.ydb-fullscreen_fullscreen .ydb-fullscreen__close-button{display:block}.ydb-fullscreen__content{display:flex;height:100%;overflow:auto;width:100%}.ydb-query-result-table__cell{cursor:pointer;display:inline-block;max-width:600px;overflow:hidden;text-overflow:ellipsis;vertical-align:middle;white-space:nowrap;width:100%}.ydb-query-result-table__message{padding:15px 10px}.kv-preview{display:flex;flex:1 1 auto;flex-direction:column;height:100%}.kv-preview .data-table__box .data-table__table-wrapper{padding-bottom:20px}.kv-preview .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.kv-preview__header{align-items:center;background-color:var(--g-color-base-background);border-bottom:1px solid var(--g-color-line-generic);display:flex;flex-shrink:0;height:53px;justify-content:space-between;padding:0 20px;position:sticky;top:0}.kv-preview__title{display:flex;gap:var(--g-spacing-1)}.kv-preview__table-name{color:var(--g-color-text-complementary);margin-left:var(--g-spacing-1)}.kv-preview__controls-left{display:flex;gap:var(--g-spacing-1)}.kv-preview__message-container{padding:15px 20px}.kv-preview__loader-container{align-items:center;display:flex;height:100%;justify-content:center}.kv-preview__result{overflow:auto;padding-left:10px;width:100%}.ydb-query-settings-description__message{display:flex;flex-wrap:wrap;white-space:pre}.ydb-query-editor-controls{align-items:flex-end;display:flex;flex:0 0 40px;gap:24px;justify-content:space-between;min-height:40px;padding:5px 0}.ydb-query-editor-controls__left,.ydb-query-editor-controls__right{display:flex;gap:12px}.ydb-query-editor-controls__mode-selector__button{margin-left:2px;width:241px}.ydb-query-editor-controls__mode-selector__button-content{align-items:center;display:flex;justify-content:space-between;width:215px}.ydb-query-editor-controls__mode-selector__popup{width:241px}.ydb-query-editor-controls__item-with-popover{align-items:center;display:flex;height:24px;line-height:normal}.ydb-query-editor-controls__popover{max-width:420px;white-space:pre-wrap}.kv-divider{background-color:var(--g-color-line-generic);height:100%;margin:0 4px;width:1px}.kv-query-execution-status{align-items:center;color:var(--g-color-text-complementary);display:flex;gap:4px}.kv-query-execution-status__result-status-icon{color:var(--g-color-text-positive)}.kv-query-execution-status__result-status-icon_error{color:var(--g-color-text-danger)}.kv-query-execution-status__query-settings-icon{color:var(--g-color-text-hint)}.cancel-query-button__stop-button_error{animation:errorAnimation .5s linear}@keyframes errorAnimation{41%,8%{transform:translateX(-2px)}25%,58%{transform:translateX(2px)}75%{transform:translateX(-1px)}92%{transform:translateX(1px)}0%,to{transform:translateX(0)}}.ydb-query-duration{align-items:center;color:var(--g-color-text-complementary);display:flex;margin-left:10px}.ydb-query-duration__item-with-popover{display:flex;white-space:nowrap}.ydb-query-duration__popover{align-items:center;display:flex}.ydb-query-duration__popover-content{max-width:300px}.ydb-query-duration__popover-button{display:flex}.ydb-query-settings-banner{margin:var(--g-spacing-1) var(--g-spacing-5)}.ydb-query-ast{height:100%;overflow:hidden;white-space:pre-wrap;width:100%}.ydb-query-result-stub-message{padding:15px 20px}.ydb-query-explain-graph__canvas-container{height:100%;overflow-y:auto;width:100%}.query-info-dropdown__menu-item{align-items:start}.query-info-dropdown__menu-item-content{display:flex;flex-direction:column;padding:var(--g-spacing-1) 0}.query-info-dropdown__icon{margin-right:var(--g-spacing-2);margin-top:var(--g-spacing-2)}.ydb-query-json-viewer__inspector{height:100%;overflow-y:auto;padding:15px 10px;width:100%}.ydb-query-result-error__message{padding:15px 10px}.ydb-query-result-sets-viewer__tabs{padding-left:10px}.ydb-query-result-sets-viewer__head{margin-top:var(--g-spacing-4)}.ydb-query-result-sets-viewer__row-count{margin-left:var(--g-spacing-1)}.ydb-query-result-sets-viewer__result-wrapper{display:flex;flex-direction:column;width:100%}.ydb-query-result-sets-viewer__result{display:flex;flex-direction:column;flex-grow:1;overflow:auto;padding-left:10px}.ydb-query-result-sets-viewer__result .data-table__box .data-table__table-wrapper{padding-bottom:20px}.ydb-query-result-sets-viewer__result .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.ydb-query-result-sets-viewer__result .data-table__table-wrapper{padding-bottom:0}.ydb-table{--ydb-table-cell-height:40px}.ydb-table__table-header-content{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:inline-flex;height:100%;padding:var(--g-spacing-1) var(--g-spacing-2);width:100%}.ydb-table__table{border-collapse:collapse;border-spacing:0;table-layout:fixed}.ydb-table__table tr:hover{background-color:var(--g-color-base-simple-hover)!important}.ydb-table__table tr:nth-of-type(odd){background-color:var(--g-color-base-generic-ultralight)}.ydb-table__table_width_max{width:100%}.ydb-table__table-header-cell{background-color:var(--g-color-base-background);font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-subheader-2-line-height);padding:0;text-align:left;vertical-align:middle}:is(.ydb-table__table-header-cell_align_right) .ydb-table__table-header-content{justify-content:flex-end;text-align:right}.ydb-table__table-cell{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-body-2-line-height);padding:0}.ydb-table__table-cell_align_right{text-align:right!important}.ydb-table__table-cell_vertical-align_top{vertical-align:top!important}.ydb-query-simplified-plan{height:100%;overflow:auto;padding:0 15px 15px;width:100%}.ydb-query-simplified-plan__name{align-items:center;display:flex;gap:var(--g-spacing-1);max-width:100%}.ydb-query-simplified-plan__metrics-cell{padding:var(--g-spacing-1) var(--g-spacing-2)}.ydb-query-simplified-plan__operation-params{color:var(--g-color-text-secondary)}.ydb-query-simplified-plan__operation-name{font-weight:500;height:100%;max-width:100%;position:relative}.ydb-query-simplified-plan__divider{bottom:0;box-shadow:1px 0 0 0 var(--g-color-line-generic) inset;height:100%;position:absolute;width:12px}.ydb-query-simplified-plan__divider_last{border-radius:0 0 0 1px;bottom:unset;box-shadow:1px -1px 0 0 var(--g-color-line-generic) inset;height:14px;top:0;width:12px}.ydb-query-simplified-plan__divider_horizontal{bottom:unset;box-shadow:0 -1px 0 0 var(--g-color-line-generic) inset;height:14px;top:0;width:12px}.ydb-query-simplified-plan__divider_first{height:calc(100% - 30px)}.ydb-query-simplified-plan__operation-content{height:100%;max-width:100%;padding:var(--g-spacing-1) 0;word-break:break-word}.ydb-query-simplified-plan__operation-name-content{display:flex;flex-grow:1}.ydb-query-result__controls{align-items:center;background-color:var(--g-color-base-background);border-bottom:1px solid var(--g-color-line-generic);display:flex;height:53px;justify-content:space-between;padding:12px 20px;position:sticky;top:0;z-index:2}.ydb-query-result__controls-left{align-items:center;display:flex;gap:12px;height:100%}.ydb-query-result__controls-right{display:flex;gap:4px}.ydb-query-result__elapsed-label{margin-left:var(--g-spacing-3)}.ydb-query-settings-select__selector{width:100%}.ydb-query-settings-select__popup{max-width:320px}.ydb-query-settings-select__item-description{color:var(--g-color-text-secondary);white-space:pre-wrap}.ydb-query-settings-select__item{padding:var(--g-spacing-1) 0}.ydb-query-settings-dialog__dialog-row+.ydb-query-settings-dialog__dialog-row{margin-top:var(--g-text-body-1-line-height)}.ydb-query-settings-dialog__field-title{flex:4 1;font-weight:500;line-height:var(--g-text-header-2-line-height);margin-right:var(--g-spacing-3);white-space:nowrap}.ydb-query-settings-dialog .g-dialog-footer__bts-wrapper{width:100%}.ydb-query-settings-dialog__dialog-body{padding-top:var(--g-spacing-6)}.ydb-query-settings-dialog__control-wrapper{display:flex;flex:6 1}.ydb-query-settings-dialog__limit-rows,.ydb-query-settings-dialog__timeout{margin-right:var(--g-spacing-2);width:33.3%}.ydb-query-settings-dialog__documentation-link,.ydb-query-settings-dialog__timeout-suffix{align-items:center;color:var(--g-color-text-secondary);display:flex}.ydb-query-settings-dialog__documentation-link{margin-left:var(--g-spacing-4)}.ydb-query-settings-dialog__buttons-container{display:flex;justify-content:space-between;width:100%}.ydb-query-settings-dialog__main-buttons{display:flex;gap:10px}.query-editor{display:flex;flex:1 1 auto;flex-direction:column;height:100%;position:relative}.query-editor .data-table__box .data-table__table-wrapper{padding-bottom:20px}.query-editor .data-table__th{box-shadow:inset 0 -1px 0 0 var(--g-tabs-color-divider)}.query-editor__monaco{border:1px solid var(--g-color-line-generic);display:flex;height:100%;position:relative;width:100%}.query-editor__monaco-wrapper{height:calc(100% - 49px);min-height:0;width:100%}.query-editor__pane-wrapper{background-color:var(--g-color-base-background);display:flex;flex-direction:column;z-index:2}.query-editor__pane-wrapper_top{border-bottom:1px solid var(--g-color-line-generic);padding:0 16px}.ydb-saved-queries{display:flex;flex:1 1 auto;flex-direction:column;height:100%;overflow:auto;padding:0 20px}.ydb-saved-queries .ydb-table-with-controls-layout__controls{height:46px;padding-top:0}.ydb-saved-queries.ydb-table-with-controls-layout .data-table__sticky_moving{top:46px!important}.ydb-saved-queries__search{width:238px}.ydb-saved-queries__row{cursor:pointer}.ydb-saved-queries__row :hover .ydb-saved-queries__controls{display:flex}.ydb-saved-queries__query-name{overflow:hidden;text-overflow:ellipsis;white-space:pre-wrap}.ydb-saved-queries__query{align-items:center;display:flex;flex-direction:row;justify-content:space-between}.ydb-saved-queries__query-body{flex-grow:1;max-width:100%;overflow:hidden;text-overflow:ellipsis;white-space:pre}.ydb-saved-queries__controls{display:none}.ydb-saved-queries__dialog-query-name{font-weight:500}.ydb-query{display:flex;flex:1 1 auto;flex-direction:column;max-height:calc(100% - 56px)}.ydb-query__tabs{padding:0 20px 16px}.ydb-query__content{height:100%;overflow:hidden}.ydb-tenant-navigation{padding:12px 16px 8px}.ydb-tenant-navigation__item{align-items:center;display:flex;gap:5px}.ydb-tenant-navigation__icon{flex-shrink:0}.ydb-tenant-navigation__text{overflow:hidden;text-overflow:ellipsis}.object-general{display:flex;flex-direction:column;flex-grow:1;height:100%;max-height:100%;width:100%}.object-general__loader{display:flex}.ydb-acl{width:100%}.ydb-acl__result{padding-bottom:var(--g-spacing-4);padding-left:var(--g-spacing-2)}.ydb-acl__result_no-title{margin-top:var(--g-spacing-3)}.ydb-acl__definition-content{align-items:flex-end;display:flex;flex-direction:column}.ydb-acl__list-title{font-weight:600;margin:var(--g-spacing-3) 0 var(--g-spacing-5)}.ydb-acl__group-label,.ydb-acl__list-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-2-line-height)}.ydb-schema-create-directory-dialog__label{display:flex;flex-direction:column;margin-bottom:8px}.ydb-schema-create-directory-dialog__description{color:var(--g-color-text-secondary)}.ydb-schema-create-directory-dialog__input-wrapper{min-height:48px}.ydb-object-summary{height:100%;max-height:100%;overflow:hidden;width:100%}.ydb-object-summary,.ydb-object-summary__overview-wrapper{display:flex;flex-direction:column;flex-grow:1;position:relative}.ydb-object-summary__overview-wrapper{overflow:auto;padding:0 12px 16px}.ydb-object-summary_hidden{visibility:hidden}.ydb-object-summary__actions{background-color:var(--g-color-base-background);position:absolute;right:5px;top:19px}.ydb-object-summary__button_hidden{display:none}.ydb-object-summary__tree-wrapper{display:flex;flex-direction:column}.ydb-object-summary__tree{flex:1 1 auto;height:100%;overflow-y:scroll;padding:0 12px 12px 16px}.ydb-object-summary__tree-header{padding:23px 12px 17px 20px}.ydb-object-summary__sticky-top{background-color:var(--g-color-base-background);left:0;position:sticky;top:0;z-index:5}.ydb-object-summary__tabs{padding:8px 12px 16px}.ydb-object-summary__tabs-inner{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic)}.ydb-object-summary__tab{text-decoration:none}.ydb-object-summary__info{display:flex;flex-direction:column;overflow:hidden}.ydb-object-summary__info-controls{display:flex;gap:4px}.ydb-object-summary__info-action-button{background-color:var(--g-color-base-background)}.ydb-object-summary__info-action-button_hidden{display:none}.ydb-object-summary__rotated90{transform:rotate(-90deg)}.ydb-object-summary__rotated180{transform:rotate(180deg)}.ydb-object-summary__rotated270{transform:rotate(90deg)}.ydb-object-summary__info-header{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:flex;justify-content:space-between;padding:12px 12px 10px}.ydb-object-summary__info-title{align-items:center;display:flex;font-weight:600;overflow:hidden}.ydb-object-summary__path-name{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-object-summary__entity-type{background-color:var(--g-color-base-generic);border-radius:3px;display:inline-block;font-weight:400;margin-right:5px;padding:3px 8px;text-transform:lowercase}.ydb-object-summary__entity-type_error{background-color:#0000;padding:3px 0}.ydb-object-summary__overview-title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.ydb-object-summary__overview-item-content{text-align:end;white-space:nowrap}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.tenant-page{display:flex;flex:1 1 auto;flex-direction:column;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);overflow:hidden}.tenant-page__main{flex-grow:1} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/8593.95df9723.chunk.css b/ydb/core/viewer/monitoring/static/css/48593.95df9723.chunk.css similarity index 100% rename from ydb/core/viewer/monitoring/static/css/8593.95df9723.chunk.css rename to ydb/core/viewer/monitoring/static/css/48593.95df9723.chunk.css diff --git a/ydb/core/viewer/monitoring/static/css/49393.3db0c827.chunk.css b/ydb/core/viewer/monitoring/static/css/49393.3db0c827.chunk.css new file mode 100644 index 000000000000..6083b2ba4891 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/49393.3db0c827.chunk.css @@ -0,0 +1 @@ +@charset "UTF-8";.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.kv-shorty-string__toggle{font-size:.85em;margin-left:1em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.link,.ydb-tablet-info__link{color:var(--g-color-text-link);text-decoration:none}.link:hover,.ydb-tablet-info__link:hover{color:var(--g-color-text-link-hover)}.ydb-tablet-info__section-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-2-line-height);margin:var(--g-spacing-1) 0 var(--g-spacing-3)}.ydb-table{--ydb-table-cell-height:40px}.ydb-table__table-header-content{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:inline-flex;height:100%;padding:var(--g-spacing-1) var(--g-spacing-2);width:100%}.ydb-table__table{border-collapse:collapse;border-spacing:0;table-layout:fixed}.ydb-table__table tr:hover{background-color:var(--g-color-base-simple-hover)!important}.ydb-table__table tr:nth-of-type(odd){background-color:var(--g-color-base-generic-ultralight)}.ydb-table__table_width_max{width:100%}.ydb-table__table-header-cell{background-color:var(--g-color-base-background);font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-subheader-2-line-height);padding:0;text-align:left;vertical-align:middle}:is(.ydb-table__table-header-cell_align_right) .ydb-table__table-header-content{justify-content:flex-end;text-align:right}.ydb-table__table-cell{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-body-2-line-height);padding:0}.ydb-table__table-cell_align_right{text-align:right!important}.ydb-table__table-cell_vertical-align_top{vertical-align:top!important}.gt-table{border:none;border-collapse:initial;border-spacing:0}.gt-table__row_interactive{cursor:pointer}.gt-table__header_sticky{inset-block-start:0;position:sticky;z-index:1}.gt-table__footer_sticky{inset-block-end:0;position:sticky;z-index:1}.gt-table__cell{font-weight:400}.gt-table__footer-cell,.gt-table__header-cell{font-weight:500;position:relative}.gt-table__cell,.gt-table__footer-cell,.gt-table__header-cell{box-sizing:border-box;height:inherit;padding:0;text-align:start}.gt-table__cell_pinned,.gt-table__footer-cell_pinned,.gt-table__header-cell_pinned{position:sticky;z-index:1}.gt-table__sort{cursor:pointer;-webkit-user-select:none;user-select:none}.gt-table_with-row-virtualization{display:grid;height:auto}.gt-table_with-row-virtualization .gt-table__body{display:grid;position:relative}.gt-table_with-row-virtualization .gt-table__footer,.gt-table_with-row-virtualization .gt-table__header{display:grid}.gt-table_with-row-virtualization .gt-table__footer-row,.gt-table_with-row-virtualization .gt-table__header-row{display:flex;height:auto}.gt-table_with-row-virtualization .gt-table__row{display:flex;height:auto;position:absolute}.gt-table_with-row-virtualization .gt-table__row_empty{position:relative}.gt-group-header{inset-inline-start:0;margin:0;position:sticky}.gt-group-header__button{appearance:none;background:inherit;border:none;cursor:pointer;display:flex;gap:8px;outline:none;padding:0;width:100%}.gt-group-header__icon{display:inline-block;transform:rotate(-90deg);transition:transform .1s ease-out;vertical-align:middle}.gt-group-header__icon_expanded{transform:rotate(0)}.gt-group-header__content{display:inline-flex;font-weight:500;gap:4px}.gt-sort-indicator{color:var(--g-color-text-hint);display:inline-flex;margin-inline-start:4px;transform:rotate(0);vertical-align:middle}.gt-sort-indicator_invisible{opacity:0}.gt-table__header-cell:hover .gt-sort-indicator_invisible{opacity:1}.gt-sort-indicator_order_asc{transform:rotate(180deg)}.gt-resize-handle{background:#d3d3d3;cursor:col-resize;height:100%;inset-block-start:0;opacity:0;position:absolute;touch-action:none;-webkit-user-select:none;user-select:none;width:6px}.gt-resize-handle_direction_ltr{inset-inline-end:0}.gt-resize-handle_direction_rtl{inset-inline-start:0}.gt-resize-handle_resizing,.gt-table__header-cell:hover .gt-resize-handle{opacity:1}.ydb-tablet-storage-info__metrics-cell{white-space:nowrap}.ydb-tablet-storage-info__metrics-cell,.ydb-tablet-storage-info__name-wrapper{padding:var(--g-spacing-1) var(--g-spacing-2)}.ydb-tablet-storage-info__with-padding{padding-left:calc(var(--g-spacing-2) + var(--g-spacing-6))}.ydb-tablet-storage-info__name-content_no-control{padding-left:var(--g-spacing-6)}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-tablet-page{font-size:var(--g-text-body-2-font-size);height:100%;line-height:var(--g-text-body-2-line-height);padding:20px}.ydb-tablet-page__placeholder{align-items:center;display:flex;flex:1 1 auto;justify-content:center}.ydb-tablet-page__loader{margin-left:var(--g-spacing-2)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/535.c6fb8cd9.chunk.css b/ydb/core/viewer/monitoring/static/css/535.c6fb8cd9.chunk.css deleted file mode 100644 index d028999af58d..000000000000 --- a/ydb/core/viewer/monitoring/static/css/535.c6fb8cd9.chunk.css +++ /dev/null @@ -1 +0,0 @@ -@charset "UTF-8";.ydb-status-icon__status-color_state_green{background-color:var(--ydb-color-status-green)}.ydb-status-icon__status-color_state_yellow{background-color:var(--ydb-color-status-yellow)}.ydb-status-icon__status-color_state_blue{background-color:var(--ydb-color-status-blue)}.ydb-status-icon__status-color_state_red{background-color:var(--ydb-color-status-red)}.ydb-status-icon__status-color_state_grey{background-color:var(--ydb-color-status-grey)}.ydb-status-icon__status-color_state_orange{background-color:var(--ydb-color-status-orange)}.ydb-status-icon__status-icon_state_blue{color:var(--ydb-color-status-blue)}.ydb-status-icon__status-icon_state_yellow{color:var(--ydb-color-status-yellow)}.ydb-status-icon__status-icon_state_orange{color:var(--ydb-color-status-orange)}.ydb-status-icon__status-icon_state_red{color:var(--ydb-color-status-red)}.ydb-status-icon__status-color,.ydb-status-icon__status-icon{border-radius:3px;display:inline-flex;flex-shrink:0}.ydb-status-icon__status-color_size_xs,.ydb-status-icon__status-icon_size_xs{aspect-ratio:1;height:12px;width:12px}.ydb-status-icon__status-color_size_s,.ydb-status-icon__status-icon_size_s{aspect-ratio:1;height:16px;width:16px}.ydb-status-icon__status-color_size_m,.ydb-status-icon__status-icon_size_m{aspect-ratio:1;height:18px;width:18px}.ydb-status-icon__status-color_size_l,.ydb-status-icon__status-icon_size_l{height:24px;width:24px}.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.kv-shorty-string__toggle{font-size:.85em;margin-left:2em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.link,.ydb-tablet-info__link{color:var(--g-color-text-link);text-decoration:none}.link:hover,.ydb-tablet-info__link:hover{color:var(--g-color-text-link-hover)}.ydb-tablet-info__section-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-2-line-height);margin:var(--g-spacing-1) 0 var(--g-spacing-3)}.ydb-table{--ydb-table-cell-height:40px}.ydb-table__table-header-content{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:inline-flex;height:100%;padding:var(--g-spacing-1) var(--g-spacing-2);width:100%}.ydb-table__table{border-collapse:collapse;border-spacing:0;table-layout:fixed}.ydb-table__table tr:hover{background-color:var(--g-color-base-simple-hover)!important}.ydb-table__table tr:nth-of-type(odd){background-color:var(--g-color-base-generic-ultralight)}.ydb-table__table_width_max{width:100%}.ydb-table__table-header-cell{background-color:var(--g-color-base-background);font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-2-font-size);font-weight:var(--g-text-subheader-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-subheader-2-line-height);padding:0;text-align:left;vertical-align:middle}:is(.ydb-table__table-header-cell_align_right) .ydb-table__table-header-content{justify-content:flex-end;text-align:right}.ydb-table__table-cell{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);height:var(--ydb-table-cell-height)!important;line-height:var(--g-text-body-2-line-height);padding:0}.ydb-table__table-cell_align_right{text-align:right!important}.ydb-table__table-cell_vertical-align_top{vertical-align:top!important}.gt-table{border:none;border-collapse:initial;border-spacing:0}.gt-table__row_interactive{cursor:pointer}.gt-table__header_sticky{inset-block-start:0;position:sticky;z-index:1}.gt-table__footer_sticky{inset-block-end:0;position:sticky;z-index:1}.gt-table__cell{font-weight:400}.gt-table__footer-cell,.gt-table__header-cell{font-weight:500;position:relative}.gt-table__cell,.gt-table__footer-cell,.gt-table__header-cell{box-sizing:border-box;height:inherit;padding:0;text-align:start}.gt-table__cell_pinned,.gt-table__footer-cell_pinned,.gt-table__header-cell_pinned{position:sticky;z-index:1}.gt-table__sort{cursor:pointer;-webkit-user-select:none;user-select:none}.gt-table_with-row-virtualization{display:grid;height:auto}.gt-table_with-row-virtualization .gt-table__body{display:grid;position:relative}.gt-table_with-row-virtualization .gt-table__footer,.gt-table_with-row-virtualization .gt-table__header{display:grid}.gt-table_with-row-virtualization .gt-table__footer-row,.gt-table_with-row-virtualization .gt-table__header-row{display:flex;height:auto}.gt-table_with-row-virtualization .gt-table__row{display:flex;height:auto;position:absolute}.gt-table_with-row-virtualization .gt-table__row_empty{position:relative}.gt-group-header{inset-inline-start:0;margin:0;position:sticky}.gt-group-header__button{appearance:none;background:inherit;border:none;cursor:pointer;display:flex;gap:8px;outline:none;padding:0;width:100%}.gt-group-header__icon{display:inline-block;transform:rotate(-90deg);transition:transform .1s ease-out;vertical-align:middle}.gt-group-header__icon_expanded{transform:rotate(0)}.gt-group-header__content{display:inline-flex;font-weight:500;gap:4px}.gt-sort-indicator{color:var(--g-color-text-hint);display:inline-flex;margin-inline-start:4px;transform:rotate(0);vertical-align:middle}.gt-sort-indicator_invisible{opacity:0}.gt-table__header-cell:hover .gt-sort-indicator_invisible{opacity:1}.gt-sort-indicator_order_asc{transform:rotate(180deg)}.gt-resize-handle{background:#d3d3d3;cursor:col-resize;height:100%;inset-block-start:0;opacity:0;position:absolute;touch-action:none;-webkit-user-select:none;user-select:none;width:6px}.gt-resize-handle_direction_ltr{inset-inline-end:0}.gt-resize-handle_direction_rtl{inset-inline-start:0}.gt-resize-handle_resizing,.gt-table__header-cell:hover .gt-resize-handle{opacity:1}.ydb-tablet-storage-info__metrics-cell{white-space:nowrap}.ydb-tablet-storage-info__metrics-cell,.ydb-tablet-storage-info__name-wrapper{padding:var(--g-spacing-1) var(--g-spacing-2)}.ydb-tablet-storage-info__with-padding{padding-left:calc(var(--g-spacing-2) + var(--g-spacing-6))}.ydb-tablet-storage-info__name-content_no-control{padding-left:var(--g-spacing-6)}.entity-status{--button-width:28px;align-items:center;display:inline-flex;font-size:var(--g-text-body-2-font-size);height:100%;line-height:var(--g-text-body-2-line-height);max-width:100%;position:relative}.entity-status__icon{margin-right:var(--g-spacing-2)}.entity-status__clipboard-button{color:var(--g-color-text-secondary);opacity:0}.entity-status__clipboard-button:focus-visible,.entity-status__clipboard-button_visible{opacity:1}.entity-status__clipboard-button:focus-visible{background-color:var(--g-color-base-float);position:absolute;right:2px;top:2px}.data-table__row:hover .entity-status__clipboard-button,.ydb-paginated-table__row:hover .entity-status__clipboard-button{opacity:1}.data-table__row:hover .entity-status__clipboard-button:focus-visible,.ydb-paginated-table__row:hover .entity-status__clipboard-button:focus-visible{background-color:unset;position:static}.entity-status__clipboard-button_visible{opacity:1}.entity-status__wrapper{overflow:hidden;position:relative}.entity-status__wrapper_with-button{padding-right:var(--button-width)}.entity-status__controls-wrapper{align-items:center;display:flex;gap:var(--g-spacing-1);height:100%;position:absolute;right:0;top:0;width:0}.entity-status__controls-wrapper_visible{padding:var(--g-spacing-1);width:min-content}.data-table__row:hover .entity-status__controls-wrapper,.ydb-paginated-table__row:hover .entity-status__controls-wrapper,.ydb-tree-view__item .entity-status__controls-wrapper{background-color:var(--ydb-data-table-color-hover);padding:var(--g-spacing-1);width:min-content}.entity-status__label{color:var(--g-color-text-complementary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin-right:2px}.entity-status__label_size_l{font-size:var(--g-text-header-2-font-size)}.entity-status__link{display:inline-block;margin-top:5px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:calc(100% + var(--button-width))}.entity-status__link_with-left-trim{direction:rtl;text-align:end}.entity-status__link_with-left-trim .entity-status__name{unicode-bidi:plaintext}.entity-status__label_state_blue{color:var(--ydb-color-status-blue)}.entity-status__label_state_yellow{color:var(--ydb-color-status-yellow)}.entity-status__label_state_orange{color:var(--ydb-color-status-orange)}.entity-status__label_state_red{color:var(--ydb-color-status-red)}.ydb-resizeable-data-table{display:flex;padding-right:20px;width:max-content}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-tablet-page{font-size:var(--g-text-body-2-font-size);height:100%;line-height:var(--g-text-body-2-line-height);padding:20px}.ydb-tablet-page__placeholder{align-items:center;display:flex;flex:1 1 auto;justify-content:center}.ydb-tablet-page__loader{margin-left:var(--g-spacing-2)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/5438.615bd68a.chunk.css b/ydb/core/viewer/monitoring/static/css/5438.615bd68a.chunk.css deleted file mode 100644 index f2b562beec19..000000000000 --- a/ydb/core/viewer/monitoring/static/css/5438.615bd68a.chunk.css +++ /dev/null @@ -1 +0,0 @@ -.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-connect-to-db-syntax-highlighter__wrapper{height:100%;position:relative;z-index:0}.ydb-connect-to-db-syntax-highlighter__sticky-container{background-color:var(--g-color-base-background);left:0;position:sticky;top:52px;top:0;z-index:1}.ydb-connect-to-db-syntax-highlighter__copy{position:absolute;right:14px;top:13px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/6030.fd13e90a.chunk.css b/ydb/core/viewer/monitoring/static/css/6030.fd13e90a.chunk.css deleted file mode 100644 index f18dd079028c..000000000000 --- a/ydb/core/viewer/monitoring/static/css/6030.fd13e90a.chunk.css +++ /dev/null @@ -1 +0,0 @@ -@charset "UTF-8";.kv-shorty-string__toggle{font-size:.85em;margin-left:2em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-info-viewer-skeleton{display:flex;flex-direction:column;gap:16px}.ydb-info-viewer-skeleton__row{align-items:flex-start;display:flex}.ydb-info-viewer-skeleton__row,.ydb-info-viewer-skeleton__row .g-skeleton{min-height:var(--g-text-body-2-font-size)}.ydb-info-viewer-skeleton__label{align-items:baseline;display:flex;flex:0 1 auto;width:200px}.ydb-info-viewer-skeleton__label__text{width:100px}.ydb-info-viewer-skeleton__label__dots{border-bottom:1px dotted var(--g-color-text-secondary);margin:0 2px;width:100px}.ydb-info-viewer-skeleton__value{max-width:20%;min-width:200px}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.ydb-vdisk-info__links{display:flex;flex-flow:row wrap;gap:var(--g-spacing-2)}.ydb-vdisk-info__title{display:flex;flex-direction:row;gap:var(--g-spacing-2)}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-vdisk-page{height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-vdisk-page__controls,.ydb-vdisk-page__info,.ydb-vdisk-page__meta,.ydb-vdisk-page__storage-title,.ydb-vdisk-page__title{left:0;margin-bottom:20px;position:sticky}.ydb-vdisk-page__meta{margin-top:20px}.ydb-vdisk-page__controls{align-items:center;display:flex;gap:var(--g-spacing-2)}.ydb-vdisk-page__storage-title{font-size:var(--g-text-header-1-font-size);line-height:var(--g-text-header-1-line-height);margin-bottom:0} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/684.90fbb646.chunk.css b/ydb/core/viewer/monitoring/static/css/684.90fbb646.chunk.css deleted file mode 100644 index 24b6299ee04d..000000000000 --- a/ydb/core/viewer/monitoring/static/css/684.90fbb646.chunk.css +++ /dev/null @@ -1 +0,0 @@ -@charset "UTF-8";.kv-shorty-string__toggle{font-size:.85em;margin-left:2em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-info-viewer-skeleton{display:flex;flex-direction:column;gap:16px}.ydb-info-viewer-skeleton__row{align-items:flex-start;display:flex}.ydb-info-viewer-skeleton__row,.ydb-info-viewer-skeleton__row .g-skeleton{min-height:var(--g-text-body-2-font-size)}.ydb-info-viewer-skeleton__label{align-items:baseline;display:flex;flex:0 1 auto;width:200px}.ydb-info-viewer-skeleton__label__text{width:100px}.ydb-info-viewer-skeleton__label__dots{border-bottom:1px dotted var(--g-color-text-secondary);margin:0 2px;width:100px}.ydb-info-viewer-skeleton__value{max-width:20%;min-width:200px}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.ydb-pdisk-info__links{display:flex;flex-flow:row wrap;gap:var(--g-spacing-2)}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.ydb-pdisk-decommission-button__button,.ydb-pdisk-decommission-button__popup{width:160px}.ydb-vdisk-info__links{display:flex;flex-flow:row wrap;gap:var(--g-spacing-2)}.ydb-vdisk-info__title{display:flex;flex-direction:row;gap:var(--g-spacing-2)}.ydb-pdisk-space-distribution .storage-disk-progress-bar{height:100%}.ydb-pdisk-space-distribution__pdisk-bar{display:flex;flex-direction:column;flex-grow:1;gap:var(--g-spacing-2);max-width:800px;min-width:500px;padding:var(--g-spacing-2)}.ydb-pdisk-space-distribution__slot-wrapper{background-color:var(--g-color-base-background);z-index:1}.ydb-pdisk-space-distribution__slot{display:flex;width:100%}.ydb-pdisk-space-distribution__slot-content{align-items:center;display:flex;flex-direction:row;flex-grow:1;justify-content:space-between;line-height:15px;padding:0 var(--g-spacing-2);z-index:1}.ydb-pdisk-space-distribution__slot-id{font-weight:600;margin-right:var(--g-spacing-3)}.ydb-pdisk-space-distribution__vdisk-popup{padding:var(--g-spacing-half) var(--g-spacing-2) var(--g-spacing-2)}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-pdisk-page{height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-pdisk-page__controls,.ydb-pdisk-page__info,.ydb-pdisk-page__meta,.ydb-pdisk-page__tabs,.ydb-pdisk-page__title{left:0;margin-bottom:20px;position:sticky}.ydb-pdisk-page__meta{margin-top:20px}.ydb-pdisk-page__tabs{margin-bottom:0}.ydb-pdisk-page__disk-distribution{padding:20px 0}.ydb-pdisk-page__title{flex-direction:row}.ydb-pdisk-page__controls,.ydb-pdisk-page__title{align-items:center;display:flex;gap:var(--g-spacing-2)}.ydb-pdisk-page__tabs{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/71867.d30d0ff3.chunk.css b/ydb/core/viewer/monitoring/static/css/71867.d30d0ff3.chunk.css new file mode 100644 index 000000000000..d1aef8129fc5 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/71867.d30d0ff3.chunk.css @@ -0,0 +1 @@ +.g-select{display:inline-block;max-width:100%}.g-select_width_max{width:100%}.g-select-filter{--g-text-input-border-color:var(--g-color-line-generic-active)}.g-select-list{display:flex;margin:4px 0;overflow:hidden}.g-popup .g-select-list:first-child,.g-popup .g-select-list:last-child{border-radius:0}.g-select-list:not(.g-select-list_virtualized){overflow:auto;position:relative}.g-select-list_mobile{max-height:100%}.g-select-list__group-label,.g-select-list__group-label-custom{box-sizing:border-box;height:auto;padding:0;position:relative;width:100%}.g-select-list__group-label{font-size:var(--g-text-body-1-font-size)}.g-select-list_size_s .g-select-list__group-label:not(.g-select-list__group-label_empty){height:24px;padding:8px 8px 4px}.g-select-list_size_m .g-select-list__group-label:not(.g-select-list__group-label_empty){height:28px;padding:8px 8px 4px}.g-select-list_size_l .g-select-list__group-label:not(.g-select-list__group-label_empty){height:36px;padding:10px 12px 6px}.g-select-list_size_xl .g-select-list__group-label:not(.g-select-list__group-label_empty){font-size:var(--g-text-body-2-font-size);height:44px;padding:12px 12px 8px}.g-select-list_mobile .g-select-list__group-label:not(.g-select-list__group-label_empty){font-size:var(--g-text-body-2-font-size);height:36px;padding:12px 12px 8px}.g-select-list__item:not(:first-child) .g-select-list__group-label{margin-block-start:5px}.g-select-list__item:not(:first-child) .g-select-list__group-label:before{background-color:var(--g-color-line-generic);content:"";height:1px;inset-block-start:-3px;inset-inline-start:0;position:absolute;width:100%}.g-select-list__group-label-content{font-weight:var(--g-text-accent-font-weight);overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:100%}.g-select-list__item.g-list__item_selected{background:none}.g-select-list__item.g-list__item_active,.g-select-list__item.g-list__item_selected:hover{background:var(--g-color-base-simple-hover)}.g-select-list__option{align-items:center;box-sizing:border-box;cursor:pointer;display:flex;height:100%;width:100%}.g-select-list_size_s .g-select-list__option{--_--select-tick-icon-padding-right:4px;padding:0 8px}.g-select-list_size_s .g-select-list__option .g-select-list__option-default-label{height:24px;line-height:24px}.g-select-list_size_m .g-select-list__option{--_--select-tick-icon-padding-right:4px;padding:0 8px}.g-select-list_size_m .g-select-list__option .g-select-list__option-default-label{height:28px;line-height:28px}.g-select-list_size_l .g-select-list__option{--_--select-tick-icon-padding-right:6px;padding:0 12px}.g-select-list_size_l .g-select-list__option .g-select-list__option-default-label{height:36px;line-height:36px}.g-select-list_size_xl .g-select-list__option{--_--select-tick-icon-padding-right:6px;padding:0 12px}.g-select-list_size_xl .g-select-list__option .g-select-list__option-default-label{font-size:var(--g-text-body-2-font-size);height:44px;line-height:44px}.g-select-list_mobile .g-select-list__option{padding:0 12px}.g-select-list_mobile .g-select-list__option .g-select-list__option-default-label{font-size:var(--g-text-body-2-font-size);height:36px;line-height:36px}.g-select-list_mobile .g-select-list__option .g-select-list__tick-icon{padding-inline-end:6px}.g-select-list__option_colored{background-color:var(--g-color-base-selection)}.g-select-list__option_disabled{cursor:default}.g-select-list__option-default-label{font-size:var(--g-text-body-1-font-size);overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:100%}.g-select-list__option-default-label_disabled{color:var(--g-color-text-secondary)}.g-select-list__tick-icon{box-sizing:initial;color:var(--g-color-text-brand);flex:0 0 16px;padding-inline-end:var(--_--select-tick-icon-padding-right);visibility:hidden}.g-select-list__tick-icon_shown{visibility:visible}.g-select-list__loading-indicator{align-items:center;display:flex;justify-content:center;width:100%}.g-select-empty-placeholder{color:var(--g-color-text-hint);margin:4px}.g-select-empty-placeholder_empty{margin-block-start:0}.g-select-counter{align-items:center;background-color:var(--g-color-base-generic);display:flex;justify-content:center;margin-inline:4px}.g-select-counter__text{flex-grow:1;margin-inline:4px;text-align:center}.g-select-counter_size_xl .g-select-counter__text{margin-inline:6px}.g-select-counter_size_s{border-radius:var(--g-border-radius-xs);height:20px;min-width:20px}.g-select-counter_size_m{border-radius:var(--g-border-radius-s);height:24px;min-width:24px}.g-select-counter_size_l{border-radius:var(--g-border-radius-m);height:28px;min-width:28px}.g-select-counter_size_xl{border-radius:var(--g-border-radius-l);height:36px;margin-inline:4px;min-width:36px}.g-select-clear{align-items:center;background:none;border:none;color:inherit;cursor:pointer;display:inline-flex;flex-shrink:0;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);justify-content:center;margin-inline-start:auto;outline:none;padding:0;z-index:1}.g-select-clear:focus-visible{border:1px solid var(--g-color-line-generic-active)}.g-select-clear_size_s{border-radius:var(--g-border-radius-s);height:24px;width:24px}.g-select-clear_size_m{border-radius:var(--g-border-radius-m);height:28px;width:28px}.g-select-clear_size_l{border-radius:var(--g-border-radius-l);height:36px;width:36px}.g-select-clear_size_xl{border-radius:var(--g-border-radius-xl);height:44px;width:44px}.g-select-clear__clear{color:var(--g-color-text-secondary)}.g-select-clear:hover .g-select-clear__clear{color:var(--g-color-text-primary)}.g-select-control{--_--focus-outline-color:var(--g-select-focus-outline-color);align-items:center;background:none;border:none;box-sizing:border-box;color:inherit;cursor:pointer;display:inline-flex;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;position:relative;transition:transform .1s ease-out;width:100%;z-index:0}.g-select-control_disabled{cursor:default}.g-select-control_size_s{--_--text-right-padding:8px;--_--border-radius:var(--g-border-radius-s);height:24px;padding:4px calc(var(--_--text-right-padding) + 1px)}.g-select-control_size_m{--_--text-right-padding:8px;--_--border-radius:var(--g-border-radius-m);height:28px;padding:6px calc(var(--_--text-right-padding) + 1px)}.g-select-control_size_l{--_--text-right-padding:12px;--_--border-radius:var(--g-border-radius-l);height:36px;padding:10px calc(var(--_--text-right-padding) + 1px)}.g-select-control_size_xl{--_--text-right-padding:12px;--_--border-radius:var(--g-border-radius-xl);height:44px;padding:12px calc(var(--_--text-right-padding) + 1px)}.g-select-control__button{align-items:center;background:none;border:none;color:inherit;cursor:pointer;display:inline-grid;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);grid-template-columns:auto auto;height:100%;justify-content:flex-start;outline:none;overflow:hidden;padding:0;transition:color .15s linear,background-color .15s linear;width:100%}.g-select-control__button.g-select-control__button_pin_round-round:before{border-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-brick:before{border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-clear:before{border-inline:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-circle:before{border-radius:100px}.g-select-control__button.g-select-control__button_pin_round-brick:before{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-round:before{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_round-clear:before{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_clear-round:before{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_brick-clear:before{border-inline-end:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-brick:before{border-inline-start:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-brick:before{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_brick-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_circle-clear:before{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_clear-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_round-round:after{border-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-brick:after{border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-clear:after{border-inline:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-circle:after{border-radius:100px}.g-select-control__button.g-select-control__button_pin_round-brick:after{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_brick-round:after{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_round-clear:after{border-end-end-radius:0;border-end-start-radius:var(--_--border-radius);border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--_--border-radius)}.g-select-control__button.g-select-control__button_pin_clear-round:after{border-end-end-radius:var(--_--border-radius);border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--_--border-radius);border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_brick-clear:after{border-inline-end:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_clear-brick:after{border-inline-start:0;border-radius:0}.g-select-control__button.g-select-control__button_pin_circle-brick:after{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_brick-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button.g-select-control__button_pin_circle-clear:after{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-select-control__button.g-select-control__button_pin_clear-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-select-control__button:before{border:1px solid var(--g-color-line-generic);border-radius:var(--_--border-radius);content:"";inset:0;position:absolute}.g-select-control__button:after{content:"";inset:0;position:absolute;z-index:-1}.g-select-control__button_view_clear,.g-select-control__button_view_clear:after,.g-select-control__button_view_clear:before{border-color:#0000}.g-select-control__button_size_l,.g-select-control__button_size_m,.g-select-control__button_size_s{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-select-control__button_size_xl{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-select-control__button_error:before{--_--focus-outline-color:var(--g-color-line-danger);border-color:var(--g-color-line-danger)}.g-select-control__button:hover:after{background-color:var(--g-color-base-simple-hover)}.g-select-control__button_disabled{color:var(--g-color-text-hint);pointer-events:none}.g-select-control__button_disabled:after{background-color:var(--g-color-base-generic-accent-disabled)}.g-select-control__button_disabled:before{border-color:#0000}.g-select-control__button:not(.g-select-control__button_error):not(.g-select-control__button_disabled):not(.g-select-control__button_view_clear):hover:before{border-color:var(--g-color-line-generic-hover)}.g-select-control__button:not(.g-select-control__button_error):not(.g-select-control__button_view_clear):focus-visible:before,.g-select-control__button_open:not(.g-select-control__button_error):not(.g-select-control__button_view_clear):before{border-color:var(--g-color-line-generic-active)}.g-select-control__button:focus-visible:before{outline:2px solid var(--g-select-focus-outline-color,var(--_--focus-outline-color));outline-offset:-1px}.g-select-control:not(.g-select-control_disabled):not(.g-select-control_no-active):active{transform:scale(.96)}.g-select-control__label{font-weight:var(--g-text-accent-font-weight);margin-inline-end:4px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-select-control__option-text,.g-select-control__placeholder{overflow:hidden;padding-inline-end:var(--_--text-right-padding);text-overflow:ellipsis;white-space:nowrap}.g-select-control_has-clear.g-select-control_size_s .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(24px + var(--_--text-right-padding))}.g-select-control_has-clear.g-select-control_size_m .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(28px + var(--_--text-right-padding))}.g-select-control_has-clear.g-select-control_size_l .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(36px + var(--_--text-right-padding))}.g-select-control_has-clear.g-select-control_size_xl .g-select-control__button_disabled .g-select-control__option-text{padding-inline-end:calc(44px + var(--_--text-right-padding))}.g-select-control__placeholder{color:var(--g-color-text-hint)}.g-select-control__chevron-icon{color:var(--g-color-text-secondary);flex:0 0 16px;margin-inline-start:auto}.g-select-control__chevron-icon_disabled{color:var(--g-color-text-hint)}.g-select-clear+.g-select-control__chevron-icon{margin-inline-start:0}.g-select-control__error-icon{background:none;border:none;border-radius:var(--g-focus-border-radius);box-sizing:initial;color:inherit;color:var(--g-color-text-danger);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;padding:var(--_--text-input-error-icon-padding)}.g-select-control__error-icon:focus{outline:2px solid var(--g-color-line-focus)}.g-select-control__error-icon:focus:not(:focus-visible){outline:0}.g-select-popup{display:flex;flex-direction:column;max-height:90vh}.g-sheet{position:fixed;z-index:100000}.g-sheet,.g-sheet__veil{height:100%;inset-block-start:0;inset-inline-start:0;width:100%}.g-sheet__veil{background-color:var(--g-color-sfx-veil);opacity:0;position:absolute;will-change:opacity}.g-sheet__veil_with-transition{transition:opacity .3s ease}.g-sheet__sheet{inset-block-start:100%;inset-inline-start:0;max-height:90%;position:absolute;width:100%;will-change:transform}.g-sheet__sheet_with-transition{transition:transform .3s ease}.g-sheet__sheet-swipe-area{height:40px;inset-block-start:-20px;inset-inline-start:0;position:absolute;width:100%;z-index:1}.g-sheet__sheet-top{background-color:var(--g-color-base-float);border-start-end-radius:20px;border-start-start-radius:20px;height:20px;position:relative}.g-sheet__sheet-top-resizer{--_--translate-x:calc(-50%*var(--g-flow-direction));background-color:var(--g-color-line-generic);border-radius:4px;height:4px;inset-block-start:50%;inset-inline-start:50%;position:absolute;transform:translateX(var(--_--translate-x)) translateY(-50%);width:40px}.g-sheet__sheet-scroll-container{background-color:var(--g-color-base-float);box-sizing:border-box;max-height:calc(90% - 20px);overflow:hidden auto;overscroll-behavior-y:contain;transition:height .3s ease}.g-sheet__sheet-scroll-container_without-scroll{overflow:hidden}.g-sheet__sheet-content-box{border:1px solid #0000}.g-sheet__sheet-content-box-border-compensation{margin:-1px}.g-sheet__sheet-content{box-sizing:border-box;padding:var(--g-sheet-content-padding,0 10px);width:100%}.g-sheet__sheet-content-title{font-size:var(--g-text-body-2-font-size);line-height:28px;overflow:hidden;padding-block-end:8px;text-align:center;text-overflow:ellipsis;white-space:nowrap}.g-arrow-toggle{display:inline-block;transition:transform .1s ease-out;vertical-align:middle}.g-arrow-toggle_direction_bottom{transform:matrix(1,0,0,1,0,0)}.g-arrow-toggle_direction_left{transform:matrix(0,1,-1,0,0,0)}.g-arrow-toggle_direction_top{transform:matrix(-1,0,0,-1,0,0)}.g-arrow-toggle_direction_right{transform:matrix(0,-1,1,0,0,0)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/85917.8ccf8efb.chunk.css b/ydb/core/viewer/monitoring/static/css/85917.8ccf8efb.chunk.css new file mode 100644 index 000000000000..53a4b3850a49 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/85917.8ccf8efb.chunk.css @@ -0,0 +1 @@ +@charset "UTF-8";.kv-shorty-string__toggle{font-size:.85em;margin-left:1em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.ydb-vdisk-info__title{display:flex;flex-direction:row;gap:var(--g-spacing-2)}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-vdisk-page{height:100%;overflow:auto;padding:0 20px;position:relative}.ydb-vdisk-page__controls,.ydb-vdisk-page__info,.ydb-vdisk-page__meta,.ydb-vdisk-page__storage-title,.ydb-vdisk-page__title{left:0;margin-bottom:20px;position:sticky}.ydb-vdisk-page__meta{margin-top:20px}.ydb-vdisk-page__controls{align-items:center;display:flex;gap:var(--g-spacing-2)}.ydb-vdisk-page__storage-title{font-size:var(--g-text-header-1-font-size);line-height:var(--g-text-header-1-line-height);margin-bottom:0} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/99.7cffb936.chunk.css b/ydb/core/viewer/monitoring/static/css/90099.7cffb936.chunk.css similarity index 100% rename from ydb/core/viewer/monitoring/static/css/99.7cffb936.chunk.css rename to ydb/core/viewer/monitoring/static/css/90099.7cffb936.chunk.css diff --git a/ydb/core/viewer/monitoring/static/css/94695.b2628977.chunk.css b/ydb/core/viewer/monitoring/static/css/94695.b2628977.chunk.css new file mode 100644 index 000000000000..613ed3465e60 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/94695.b2628977.chunk.css @@ -0,0 +1 @@ +.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-syntax-highlighter{height:100%;position:relative;z-index:0}.ydb-syntax-highlighter__sticky-container{background-color:var(--g-color-base-background);left:0;position:sticky;top:52px;top:0;z-index:1}.ydb-syntax-highlighter__copy{opacity:0;pointer-events:all;position:absolute;right:14px;top:13px}.data-table__row:hover .ydb-syntax-highlighter__copy,.ydb-paginated-table__row:hover .ydb-syntax-highlighter__copy,.ydb-syntax-highlighter__copy_visible{opacity:1} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/96079.84d6fbfd.chunk.css b/ydb/core/viewer/monitoring/static/css/96079.84d6fbfd.chunk.css new file mode 100644 index 000000000000..ae1401ce7f33 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/96079.84d6fbfd.chunk.css @@ -0,0 +1 @@ +@charset "UTF-8";.ydb-entity-page-title{text-wrap:nowrap;align-items:baseline;display:flex;flex-flow:row nowrap;font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.ydb-entity-page-title__prefix{color:var(--g-color-text-secondary);margin-right:6px}.ydb-entity-page-title__icon{margin-right:8px}.ydb-pool-usage{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.ydb-pool-usage__info{align-items:center;display:flex;justify-content:space-between}.ydb-pool-usage__pool-name{color:var(--g-color-text-primary)}.ydb-pool-usage__value{align-items:center;display:flex}.ydb-pool-usage__threads{color:var(--g-color-text-hint);font-size:var(--g-text-body-1-font-size)}.ydb-pool-usage__percents{color:var(--g-color-text-primary);font-size:var(--g-text-body-1-font-size);margin-right:2px}.ydb-pool-usage__visual{align-items:center;background-color:var(--g-color-base-generic-accent);border-radius:4px;display:flex;font-size:var(--g-text-body-2-font-size);height:6px;justify-content:center;overflow:hidden;position:relative}.ydb-pool-usage__usage-line{height:100%;left:0;position:absolute;top:0}.ydb-pool-usage__usage-line_type_green{background-color:var(--ydb-color-status-green)}.ydb-pool-usage__usage-line_type_blue{background-color:var(--ydb-color-status-blue)}.ydb-pool-usage__usage-line_type_yellow{background-color:var(--ydb-color-status-yellow)}.ydb-pool-usage__usage-line_type_red{background-color:var(--ydb-color-status-red)}.full-node-viewer{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.full-node-viewer__section{display:flex;flex-direction:column;max-width:500px;min-width:300px;width:max-content}.full-node-viewer__section_pools{grid-gap:7px 20px;display:grid;grid-template-columns:110px 110px}.full-node-viewer .info-viewer__label{min-width:100px}.full-node-viewer__section-title{font-size:var(--g-text-body-2-font-size);font-weight:600;line-height:var(--g-text-body-2-line-height);margin:15px 0 10px}.full-node-viewer__role{color:var(--g-color-text-secondary)}.ydb-page-meta__info{text-wrap:nowrap;color:var(--g-color-text-primary);display:flex;flex-flow:row nowrap;flex-grow:1;font-size:var(--g-text-body-2-font-size);height:var(--g-text-body-2-line-height);line-height:var(--g-text-body-2-line-height)}.ydb-page-meta__skeleton{height:80%;width:80%}.kv-shorty-string__toggle{font-size:.85em;margin-left:1em}.kv-result-issues{padding:0 10px}.kv-result-issues__error-message{align-items:center;background-color:var(--g-color-base-background);display:flex;left:0;padding:10px 0;position:sticky;top:0;z-index:2}.kv-result-issues__error-message-text{margin:0 10px}.kv-issues{position:relative}.kv-issue_leaf{margin-left:31px}.kv-issue__issues{padding-left:24px}.kv-issue__line{align-items:flex-start;display:flex;margin:0 0 10px;padding:0 10px 0 0}.kv-issue__place-text{color:var(--g-color-text-secondary);display:inline-block;padding-right:10px;text-align:left}.kv-issue__message{display:flex;font-family:var(--g-font-family-monospace);font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-header-2-line-height);margin-left:10px;margin-right:auto}.kv-issue__message-text{flex:1 1 auto;min-width:240px;white-space:pre-wrap;word-break:break-word}.kv-issue__code{color:var(--g-color-text-complementary);flex:0 0 auto;font-size:12px;margin-left:1.5em;padding:3px 0}.kv-issue__arrow-toggle{margin-right:5px}.yql-issue-severity{align-items:center;display:flex;line-height:28px;white-space:nowrap}.yql-issue-severity_severity_error .yql-issue-severity__icon,.yql-issue-severity_severity_fatal .yql-issue-severity__icon{color:var(--g-color-text-danger)}.yql-issue-severity_severity_warning .yql-issue-severity__icon{color:var(--g-color-text-warning)}.yql-issue-severity_severity_info .yql-issue-severity__icon{color:var(--g-color-text-info)}.yql-issue-severity__title{color:var(--g-color-text-complementary);margin-left:4px;text-transform:capitalize}.ydb-critical-dialog{padding-top:var(--g-spacing-3)}.ydb-critical-dialog__warning-icon{color:var(--ydb-color-status-yellow);margin-right:16px}.ydb-critical-dialog__error-icon{color:var(--ydb-color-status-red);height:24px;margin-right:16px}.ydb-critical-dialog__body{display:flex;flex-direction:column;gap:var(--g-spacing-6)}.ydb-critical-dialog__body-message{align-items:center;display:flex}.ydb-critical-dialog__body-message_error,.ydb-critical-dialog__body-message_warning{border:1px solid;border-radius:var(--g-modal-border-radius,5px);padding:var(--g-spacing-4) var(--g-spacing-5)}.ydb-critical-dialog__body-message_warning{border-color:var(--ydb-color-status-yellow)}.ydb-critical-dialog__body-message_error{border-color:var(--ydb-color-status-red)}.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.ydb-vdisk-info__title{display:flex;flex-direction:row;gap:var(--g-spacing-2)}.kv-node-structure{display:flex;flex-shrink:0;flex:1 1 auto;flex-direction:column;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);overflow:auto;position:relative}.kv-node-structure__error{padding:20px 20px 0}.kv-node-structure__pdisk{border:1px solid var(--g-color-line-generic);border-radius:5px;display:flex;flex-direction:column;margin-bottom:8px;padding:0 10px 0 20px;width:573px}.kv-node-structure__pdisk-id{align-items:flex-end;display:flex}.kv-node-structure__pdisk-header{align-items:center;display:flex;height:48px;justify-content:space-between}.kv-node-structure__pdisk-title-wrapper{align-items:center;display:flex;font-weight:600;gap:16px}.kv-node-structure__pdisk-title-wrapper .entity-status__status-icon{margin-right:0}.kv-node-structure__pdisk-title-item{display:flex;gap:4px}.kv-node-structure__pdisk-title-item-label{color:var(--g-color-text-secondary);font-weight:400}.kv-node-structure__pdisk-title-id{min-width:110px}.kv-node-structure__pdisk-title-type{justify-content:flex-end;min-width:50px}.kv-node-structure__pdisk-title-size{min-width:150px}.kv-node-structure__pdisk-details{margin-bottom:20px}.kv-node-structure__link{color:var(--g-color-base-brand);text-decoration:none}.kv-node-structure__vdisks-header{font-weight:600}.kv-node-structure__vdisks-container{margin-bottom:42px}.kv-node-structure__vdisk-details{max-height:90vh;max-width:unset;min-width:200px;overflow:auto}.kv-node-structure__vdisk-details .vdisk-pdisk-node__column{margin-bottom:0}.kv-node-structure__vdisk-details .vdisk-pdisk-node__section{padding-bottom:0}.kv-node-structure__vdisk-id{align-items:center;display:flex}.kv-node-structure__vdisk-details-button_selected,.kv-node-structure__vdisk-id_selected{color:var(--g-color-text-info)}.kv-node-structure__external-button{align-items:center;display:inline-flex;margin-left:4px;transform:translateY(-1px)}.kv-node-structure__external-button_hidden{visibility:hidden}.kv-node-structure .data-table__row:hover .kv-node-structure__external-button_hidden{visibility:visible}.kv-node-structure__selected-vdisk{animation:onSelectedVdiskAnimation 4s}@keyframes onSelectedVdiskAnimation{0%{background-color:var(--g-color-base-info-light-hover)}}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.node{height:100%;overflow:auto;padding:0 20px;position:relative}.node__error,.node__info,.node__meta,.node__tabs,.node__title{left:0;margin-bottom:20px;position:sticky}.node__meta{margin-top:20px}.node__error,.node__tabs{margin-bottom:0}.node__tabs{--g-tabs-border-width:0;box-shadow:inset 0 -1px 0 0 var(--g-color-line-generic)} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/9796.828f7385.chunk.css b/ydb/core/viewer/monitoring/static/css/9796.828f7385.chunk.css deleted file mode 100644 index 98356eac336f..000000000000 --- a/ydb/core/viewer/monitoring/static/css/9796.828f7385.chunk.css +++ /dev/null @@ -1 +0,0 @@ -.auto-refresh-control{align-items:center;display:flex;gap:var(--g-spacing-1)}.table-skeleton__wrapper{width:100%}.table-skeleton__wrapper_hidden{visibility:hidden}.table-skeleton__row{align-items:center;display:flex;height:var(--data-table-row-height)}.table-skeleton__row .g-skeleton{height:var(--g-text-body-2-line-height)}.table-skeleton__col-1{margin-right:5%;width:10%}.table-skeleton__col-2{margin-right:5%;width:7%}.table-skeleton__col-3,.table-skeleton__col-4{margin-right:5%;width:5%}.table-skeleton__col-5{width:20%}.table-skeleton__col-full{width:100%}.ydb-table-with-controls-layout{--data-table-sticky-top-offset:62px;box-sizing:border-box;display:inline-block;min-width:100%}.ydb-table-with-controls-layout__controls-wrapper{background-color:var(--g-color-base-background);box-sizing:border-box;left:0;position:sticky;top:0;width:100%;z-index:3}.ydb-table-with-controls-layout__controls{align-items:center;background-color:var(--g-color-base-background);display:flex;gap:12px;height:62px;left:0;padding:16px 0 18px;position:sticky;top:0;width:max-content;z-index:3}.ydb-table-with-controls-layout__table{position:relative;z-index:2}.ydb-table-with-controls-layout .ydb-paginated-table__head{top:var(--data-table-sticky-top-offset,62px)}.ydb-table-with-controls-layout .data-table__sticky_moving{top:var(--data-table-sticky-top-offset,62px)!important}.ydb-status-icon__status-color_state_green{background-color:var(--ydb-color-status-green)}.ydb-status-icon__status-color_state_yellow{background-color:var(--ydb-color-status-yellow)}.ydb-status-icon__status-color_state_blue{background-color:var(--ydb-color-status-blue)}.ydb-status-icon__status-color_state_red{background-color:var(--ydb-color-status-red)}.ydb-status-icon__status-color_state_grey{background-color:var(--ydb-color-status-grey)}.ydb-status-icon__status-color_state_orange{background-color:var(--ydb-color-status-orange)}.ydb-status-icon__status-icon_state_blue{color:var(--ydb-color-status-blue)}.ydb-status-icon__status-icon_state_yellow{color:var(--ydb-color-status-yellow)}.ydb-status-icon__status-icon_state_orange{color:var(--ydb-color-status-orange)}.ydb-status-icon__status-icon_state_red{color:var(--ydb-color-status-red)}.ydb-status-icon__status-color,.ydb-status-icon__status-icon{border-radius:3px;display:inline-flex;flex-shrink:0}.ydb-status-icon__status-color_size_xs,.ydb-status-icon__status-icon_size_xs{aspect-ratio:1;height:12px;width:12px}.ydb-status-icon__status-color_size_s,.ydb-status-icon__status-icon_size_s{aspect-ratio:1;height:16px;width:16px}.ydb-status-icon__status-color_size_m,.ydb-status-icon__status-icon_size_m{aspect-ratio:1;height:18px;width:18px}.ydb-status-icon__status-color_size_l,.ydb-status-icon__status-icon_size_l{height:24px;width:24px}.progress-viewer{align-items:center;background:var(--g-color-base-generic);border-radius:2px;color:var(--g-color-text-complementary);display:flex;font-size:var(--g-text-body-2-font-size);height:23px;justify-content:center;min-width:150px;overflow:hidden;padding:0 4px;position:relative;white-space:nowrap;z-index:0}.progress-viewer_theme_dark{color:var(--g-color-text-light-primary)}.progress-viewer_theme_dark .progress-viewer__line{opacity:.75}.progress-viewer_status_good{background-color:var(--g-color-base-positive-light)}.progress-viewer_status_good .progress-viewer__line{background-color:var(--ydb-color-status-green)}.progress-viewer_status_warning{background-color:var(--g-color-base-yellow-light)}.progress-viewer_status_warning .progress-viewer__line{background-color:var(--ydb-color-status-yellow)}.progress-viewer_status_danger{background-color:var(--g-color-base-danger-light)}.progress-viewer_status_danger .progress-viewer__line{background-color:var(--ydb-color-status-red)}.progress-viewer__line{height:100%;left:0;position:absolute;top:0}.progress-viewer__text{position:relative;z-index:1}.progress-viewer_size_xs{font-size:var(--g-text-body-2-font-size);height:20px;line-height:var(--g-text-body-2-line-height)}.progress-viewer_size_s{font-size:var(--g-text-body-1-font-size);height:28px;line-height:28px}.progress-viewer_size_m{font-size:var(--g-text-body-2-font-size);height:32px;line-height:32px}.progress-viewer_size_ns{font-size:13px;height:24px;line-height:var(--g-text-subheader-3-line-height)}.progress-viewer_size_n{font-size:var(--g-text-body-1-font-size);height:36px;line-height:36px}.progress-viewer_size_l{font-size:var(--g-text-subheader-3-font-size);height:38px;line-height:38px}.progress-viewer_size_head{font-size:var(--g-text-body-1-font-size);line-height:36px}.ydb-search{min-width:100px}.ydb-paginated-table{--paginated-table-cell-vertical-padding:5px;--paginated-table-cell-horizontal-padding:10px;--paginated-table-border-color:var(--g-color-base-generic-hover);--paginated-table-hover-color:var(--g-color-base-simple-hover-solid);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);width:100%}.ydb-paginated-table__table{border-collapse:initial;border-spacing:0;max-width:100%;table-layout:fixed;width:max-content}.ydb-paginated-table__table th{padding:0}.ydb-paginated-table__row{position:relative;transform:translateZ(0);z-index:1}.ydb-paginated-table__row:hover{background:var(--paginated-table-hover-color)}.ydb-paginated-table__row_empty:hover{background-color:initial}.ydb-paginated-table__head{background-color:var(--g-color-base-background);left:0;position:sticky;top:0;z-index:2}.ydb-paginated-table__sort-icon-container{color:inherit;display:flex;justify-content:center}.ydb-paginated-table__sort-icon-container_shadow{opacity:.15}.ydb-paginated-table__sort-icon_desc{transform:rotate(180deg)}.ydb-paginated-table__head-cell-wrapper{border-bottom:1px solid var(--paginated-table-border-color);display:table-cell;overflow-x:hidden;position:relative}.ydb-paginated-table__head-cell{align-items:center;display:flex;flex-direction:row;max-width:100%;padding:var(--paginated-table-cell-vertical-padding) var(--paginated-table-cell-horizontal-padding);width:100%}.ydb-paginated-table__head-cell_align_left{justify-content:left}.ydb-paginated-table__head-cell_align_center{justify-content:center}.ydb-paginated-table__head-cell_align_right{justify-content:right}.ydb-paginated-table__head-cell{cursor:default;font-weight:700;gap:8px}.ydb-paginated-table__head-cell_sortable{cursor:pointer}.ydb-paginated-table__head-cell_sortable.ydb-paginated-table__head-cell_align_right{flex-direction:row-reverse}.ydb-paginated-table__head-cell-content{overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:min-content}.ydb-paginated-table__row-cell{border-bottom:1px solid var(--paginated-table-border-color);display:table-cell;max-width:100%;overflow-x:hidden;padding:var(--paginated-table-cell-vertical-padding) var(--paginated-table-cell-horizontal-padding);text-overflow:ellipsis;vertical-align:middle;white-space:nowrap;width:100%}.ydb-paginated-table__row-cell_align_left{text-align:left}.ydb-paginated-table__row-cell_align_center{text-align:center}.ydb-paginated-table__row-cell_align_right{text-align:right}.ydb-paginated-table__resize-handler{background-color:var(--g-color-base-generic);cursor:col-resize;height:100%;position:absolute;right:0;top:0;visibility:hidden;width:6px}.ydb-paginated-table__head-cell-wrapper:hover>.ydb-paginated-table__resize-handler,.ydb-paginated-table__resize-handler_resizing{visibility:visible}.ydb-paginated-table__resizeable-table-container{padding-right:20px;width:max-content}.ydb-paginated-table__row-skeleton:after{animation:none!important}.ydb-usage-label_overload{background-color:var(--ydb-color-status-red);color:var(--g-color-text-light-primary)}.storage-disk-progress-bar{--progress-bar-full-height:var(--g-text-body-3-line-height);--progress-bar-compact-height:12px;--entity-state-border-color:var(--g-color-base-misc-heavy);--entity-state-background-color:var(--g-color-base-misc-light);--entity-state-fill-color:var(--g-color-base-misc-medium);--entity-state-font-color:var(--g-color-text-primary);background-color:var(--entity-state-background-color);border:1px solid var(--entity-state-border-color);border-radius:4px;color:var(--g-color-text-primary);height:var(--progress-bar-full-height);min-width:50px;position:relative;text-align:center;z-index:0}.storage-disk-progress-bar_green{--entity-state-font-color:var(--g-color-text-positive);--entity-state-border-color:var(--g-color-base-positive-heavy);--entity-state-background-color:var(--g-color-base-positive-light);--entity-state-fill-color:var(--g-color-base-positive-medium)}.storage-disk-progress-bar_blue{--entity-state-font-color:var(--g-color-text-info);--entity-state-border-color:var(--g-color-base-info-heavy);--entity-state-background-color:var(--g-color-base-info-light);--entity-state-fill-color:var(--g-color-base-info-medium)}.storage-disk-progress-bar_yellow{--entity-state-font-color:var(--g-color-text-warning);--entity-state-border-color:var(--g-color-base-warning-heavy);--entity-state-background-color:var(--g-color-base-yellow-light);--entity-state-fill-color:var(--g-color-base-yellow-medium)}.storage-disk-progress-bar_orange{--entity-state-font-color:var(--g-color-private-orange-500);--entity-state-border-color:var(--ydb-color-status-orange);--entity-state-background-color:var(--g-color-private-orange-100);--entity-state-fill-color:var(--g-color-private-orange-300)}.storage-disk-progress-bar_red{--entity-state-font-color:var(--g-color-text-danger);--entity-state-border-color:var(--g-color-base-danger-heavy);--entity-state-background-color:var(--g-color-base-danger-light);--entity-state-fill-color:var(--g-color-base-danger-medium)}.storage-disk-progress-bar__grey{--entity-state-font-color:var(--g-color-text-secondary);--entity-state-border-color:var(--g-color-line-generic-hover)}.storage-disk-progress-bar_compact{border-radius:2px;height:var(--progress-bar-compact-height);min-width:0}.storage-disk-progress-bar_faded{background-color:unset}.storage-disk-progress-bar_inactive{opacity:.5}.storage-disk-progress-bar_empty{background-color:unset;border-style:dashed;color:var(--g-color-text-hint)}.storage-disk-progress-bar__fill-bar{background-color:var(--entity-state-fill-color);border-radius:3px 0 0 3px;height:100%;left:0;position:absolute;top:0}.storage-disk-progress-bar__fill-bar_faded{background-color:var(--entity-state-background-color)}.storage-disk-progress-bar__fill-bar_compact{border-radius:1px}.storage-disk-progress-bar__fill-bar_inverted{border-radius:0 3px 3px 0;left:auto;right:0}.storage-disk-progress-bar__title{color:inherit;font-size:var(--g-text-body-1-font-size);line-height:calc(var(--progress-bar-full-height) - 2px);position:relative;z-index:2}.hover-popup{padding:var(--g-spacing-3)}.vdisk-storage-popup .info-viewer+.info-viewer{border-top:1px solid var(--g-color-line-generic);margin-top:8px;padding-top:8px}.vdisk-storage-popup__donor-label{margin-bottom:8px}.ydb-table-group{border:1px solid var(--g-color-line-generic);border-radius:var(--g-spacing-2);display:flex;flex-direction:column;margin-bottom:20px;width:100%}.ydb-table-group__button{background:unset;border:unset;cursor:pointer;padding:8px 0}.ydb-table-group__title-wrapper{align-items:center;display:flex;flex-direction:row;gap:var(--g-spacing-2);justify-content:flex-start;left:0;padding-left:20px;position:sticky;width:max-content}.ydb-table-group__title{display:flex;flex-direction:row;gap:var(--g-spacing-4)}.ydb-table-group__count{display:flex;flex-direction:row;gap:var(--g-spacing-3)}.ydb-table-group__content{padding:12px 0 20px 20px}.ydb-vdisk-component{border-radius:4px}.ydb-vdisk-component__content{border-radius:4px;display:block}.pdisk-storage{display:flex;flex-direction:column;justify-content:flex-end;min-width:var(--pdisk-min-width);position:relative;width:var(--pdisk-width)}.pdisk-storage__content{border-radius:4px;display:block;flex:1 1;position:relative}.pdisk-storage__vdisks{display:flex;flex:0 0 auto;gap:var(--pdisk-gap-width);margin-bottom:4px;white-space:nowrap}.pdisk-storage__vdisks-item{flex:0 0 var(--pdisk-vdisk-width);min-width:var(--pdisk-vdisk-width)}.data-table__row:hover .pdisk-storage__vdisks-item .stack__layer{background:var(--ydb-data-table-color-hover)}.pdisk-storage__donors-stack{--ydb-stack-offset-x:0px;--ydb-stack-offset-y:-2px;--ydb-stack-offset-x-hover:0px;--ydb-stack-offset-y-hover:-7px}.pdisk-storage__media-type{color:var(--g-color-text-secondary);font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height);position:absolute;right:4px;top:50%;transform:translateY(-50%)}.ydb-storage-disks{align-items:center;display:flex;flex-direction:row;gap:20px;width:max-content}.ydb-storage-disks__pdisks-wrapper{display:flex;flex-direction:row;justify-content:left;width:max-content}.ydb-storage-disks__vdisk-item{flex-basis:8px;flex-shrink:0}.ydb-storage-disks__vdisk-progress-bar{--progress-bar-compact-height:18px;border-radius:4px}.ydb-storage-disks__pdisk-item{margin-right:4px;min-width:80px}.ydb-storage-disks__pdisk-item_with-dc-margin{margin-right:12px}.ydb-storage-disks__pdisk-item:last-child{margin-right:0}.ydb-storage-disks__pdisk-progress-bar{--progress-bar-full-height:20px;padding-left:var(--g-spacing-2);text-align:left}.entity-status{--button-width:28px;align-items:center;display:inline-flex;font-size:var(--g-text-body-2-font-size);height:100%;line-height:var(--g-text-body-2-line-height);max-width:100%;position:relative}.entity-status__icon{margin-right:var(--g-spacing-2)}.entity-status__clipboard-button{color:var(--g-color-text-secondary);opacity:0}.entity-status__clipboard-button:focus-visible,.entity-status__clipboard-button_visible{opacity:1}.entity-status__clipboard-button:focus-visible{background-color:var(--g-color-base-float);position:absolute;right:2px;top:2px}.data-table__row:hover .entity-status__clipboard-button,.ydb-paginated-table__row:hover .entity-status__clipboard-button{opacity:1}.data-table__row:hover .entity-status__clipboard-button:focus-visible,.ydb-paginated-table__row:hover .entity-status__clipboard-button:focus-visible{background-color:unset;position:static}.entity-status__clipboard-button_visible{opacity:1}.entity-status__wrapper{overflow:hidden;position:relative}.entity-status__wrapper_with-button{padding-right:var(--button-width)}.entity-status__controls-wrapper{align-items:center;display:flex;gap:var(--g-spacing-1);height:100%;position:absolute;right:0;top:0;width:0}.entity-status__controls-wrapper_visible{padding:var(--g-spacing-1);width:min-content}.data-table__row:hover .entity-status__controls-wrapper,.ydb-paginated-table__row:hover .entity-status__controls-wrapper,.ydb-tree-view__item .entity-status__controls-wrapper{background-color:var(--ydb-data-table-color-hover);padding:var(--g-spacing-1);width:min-content}.entity-status__label{color:var(--g-color-text-complementary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin-right:2px}.entity-status__label_size_l{font-size:var(--g-text-header-2-font-size)}.entity-status__link{display:inline-block;margin-top:5px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:calc(100% + var(--button-width))}.entity-status__link_with-left-trim{direction:rtl;text-align:end}.entity-status__link_with-left-trim .entity-status__name{unicode-bidi:plaintext}.entity-status__label_state_blue{color:var(--ydb-color-status-blue)}.entity-status__label_state_yellow{color:var(--ydb-color-status-yellow)}.entity-status__label_state_orange{color:var(--ydb-color-status-orange)}.entity-status__label_state_red{color:var(--ydb-color-status-red)}.memory-viewer{min-width:150px;padding:0 var(--g-spacing-1);position:relative;z-index:0}.memory-viewer__progress-container{background:var(--g-color-base-generic);border-radius:2px;height:20px;overflow:hidden;position:relative}.memory-viewer__container{display:flex;padding:2px 0}.memory-viewer__legend{border-radius:2px;bottom:2px;height:20px;position:absolute;width:20px}.memory-viewer__legend_type_AllocatorCachesMemory{background-color:var(--g-color-base-utility-medium-hover)}.memory-viewer__legend_type_SharedCacheConsumption{background-color:var(--g-color-base-info-medium-hover)}.memory-viewer__legend_type_MemTableConsumption{background-color:var(--g-color-base-warning-medium-hover)}.memory-viewer__legend_type_QueryExecutionConsumption{background-color:var(--g-color-base-positive-medium-hover)}.memory-viewer__legend_type_Other{background-color:var(--g-color-base-generic-medium-hover)}.memory-viewer__segment{height:100%;position:absolute}.memory-viewer__segment_type_AllocatorCachesMemory{background-color:var(--g-color-base-utility-medium-hover)}.memory-viewer__segment_type_SharedCacheConsumption{background-color:var(--g-color-base-info-medium-hover)}.memory-viewer__segment_type_MemTableConsumption{background-color:var(--g-color-base-warning-medium-hover)}.memory-viewer__segment_type_QueryExecutionConsumption{background-color:var(--g-color-base-positive-medium-hover)}.memory-viewer__segment_type_Other{background-color:var(--g-color-base-generic-medium-hover)}.memory-viewer__name{padding-left:28px}.memory-viewer_theme_dark{color:var(--g-color-text-light-primary)}.memory-viewer_theme_dark .memory-viewer__segment{opacity:.75}.memory-viewer_status_good .memory-viewer__progress-container{background-color:var(--g-color-base-positive-light)}.memory-viewer_status_warning .memory-viewer__progress-container{background-color:var(--g-color-base-yellow-light)}.memory-viewer_status_danger .memory-viewer__progress-container{background-color:var(--g-color-base-danger-light)}.memory-viewer__text{align-items:center;display:flex;justify-content:center}.stack{--ydb-stack-base-z-index:100;--ydb-stack-offset-x:4px;--ydb-stack-offset-y:4px;--ydb-stack-offset-x-hover:4px;--ydb-stack-offset-y-hover:6px;position:relative}.stack__layer{background:var(--g-color-base-background);transition:transform .1s ease-out}.stack__layer:first-child{position:relative;z-index:var(--ydb-stack-base-z-index)}.stack__layer+.stack__layer{height:100%;left:0;position:absolute;top:0;transform:translate(calc(var(--ydb-stack-level)*var(--ydb-stack-offset-x)),calc(var(--ydb-stack-level)*var(--ydb-stack-offset-y)));width:100%;z-index:calc(var(--ydb-stack-base-z-index) - var(--ydb-stack-level))}.stack:hover .stack__layer:first-child{transform:translate(calc(var(--ydb-stack-offset-x-hover)*-1),calc(var(--ydb-stack-offset-y-hover)*-1))}.stack:hover .stack__layer+.stack__layer{transform:translate(calc(var(--ydb-stack-level)*var(--ydb-stack-offset-x-hover)*2 - var(--ydb-stack-offset-x-hover)),calc(var(--ydb-stack-level)*var(--ydb-stack-offset-y-hover)*2 - var(--ydb-stack-offset-y-hover)))}.ydb-pool-bar{border:1px solid;border-radius:1px;cursor:pointer;height:20px;margin-right:2px;position:relative;width:6px}.ydb-pool-bar__popup-content{padding:10px;width:170px}.ydb-pool-bar:last-child{margin-right:0}.ydb-pool-bar_type_normal{border-color:var(--ydb-color-status-green)}.ydb-pool-bar_type_warning{border-color:var(--ydb-color-status-yellow)}.ydb-pool-bar_type_danger{border-color:var(--ydb-color-status-red)}.ydb-pool-bar__value{bottom:0;min-height:1px;position:absolute;width:100%}.ydb-pool-bar__value_type_normal{background-color:var(--ydb-color-status-green)}.ydb-pool-bar__value_type_warning{background-color:var(--ydb-color-status-yellow)}.ydb-pool-bar__value_type_danger{background-color:var(--ydb-color-status-red)}.ydb-storage-vdisks__wrapper{display:flex}.ydb-storage-vdisks__item{margin-right:6px;width:90px}.ydb-storage-vdisks__item_with-dc-margin{margin-right:12px}.ydb-storage-vdisks__item:last-child{margin-right:0}.data-table__row:hover .ydb-storage-vdisks__item .stack__layer{background:var(--ydb-data-table-color-hover)}.ydb-pools-graph{display:flex}.ydb-storage-groups-columns__disks-column,.ydb-storage-groups-columns__vdisks-column{overflow:visible}.ydb-storage-groups-columns__pool-name-wrapper{direction:rtl;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-storage-groups-columns__pool-name{unicode-bidi:plaintext}.ydb-storage-groups-columns__group-id{font-weight:500}.tablets-statistic{align-items:center;display:flex;gap:2px}.tablets-statistic__tablet{border:1px solid;border-radius:2px;color:var(--g-color-text-secondary);display:inline-block;font-size:11px;height:20px;line-height:20px;padding:0 4px;text-align:center;text-decoration:none;text-transform:uppercase}.tablets-statistic__tablet_state_green{background-color:var(--g-color-base-positive-light);color:var(--g-color-text-positive)}.tablets-statistic__tablet_state_yellow{background-color:var(--g-color-base-warning-light);color:var(--g-color-text-warning)}.tablets-statistic__tablet_state_blue{background-color:var(--g-color-base-info-light);color:var(--g-color-text-info)}.tablets-statistic__tablet_state_orange{background-color:var(--g-color-base-warning-light);color:var(--g-color-text-warning-heavy)}.tablets-statistic__tablet_state_red{background:var(--g-color-base-danger-light);color:var(--g-color-text-danger)}.tablets-statistic__tablet_state_grey{border:1px solid var(--g-color-line-generic-hover);color:var(--g-color-text-secondary)}.global-storage__search{width:238px}.global-storage__table .g-tooltip{height:var(--g-text-body-2-line-height)!important}.global-storage .entity-status{justify-content:center}.global-storage__groups-wrapper{padding-right:20px}.ydb-nodes-columns__column-cpu,.ydb-nodes-columns__column-ram{min-width:40px}.ydb-storage-nodes__node_unavailable{opacity:.6}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.ydb-storage-nodes-columns__pdisks-column{overflow:visible}.ydb-storage-nodes-columns__pdisks-wrapper{--pdisk-vdisk-width:3px;--pdisk-gap-width:2px;--pdisk-min-width:120px;--pdisk-margin:10px;--pdisk-width:max(calc(var(--maximum-slots, 1)*var(--pdisk-vdisk-width) + (var(--maximum-slots, 1) - 1)*var(--pdisk-gap-width)),var(--pdisk-min-width));--pdisks-container-width:calc(var(--maximum-disks, 1)*var(--pdisk-width) + (var(--maximum-disks, 1) - 1)*var(--pdisk-margin));display:flex;gap:var(--pdisk-margin);height:40px;width:var(--pdisks-container-width)}.ydb-storage-nodes-columns__pdisks-item{display:flex;flex-shrink:0} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/985.8e5e0423.chunk.css b/ydb/core/viewer/monitoring/static/css/985.8e5e0423.chunk.css deleted file mode 100644 index c05c0ec4d3c9..000000000000 --- a/ydb/core/viewer/monitoring/static/css/985.8e5e0423.chunk.css +++ /dev/null @@ -1,3 +0,0 @@ -@charset "UTF-8";.g-checkbox__indicator{cursor:inherit;display:inline-block;position:relative}.g-checkbox__indicator:before{background-color:initial;border:1px solid var(--g-color-line-generic-accent);border-radius:4px;content:"";inset:0;position:absolute;transition:background .1s linear}.g-checkbox__indicator:after{content:" ";visibility:hidden}.g-checkbox__icon{align-items:center;color:#0000;display:flex;inset:0;justify-content:center;pointer-events:none;position:absolute;transform:translateY(-5px);transition:color .1s,transform .2s;visibility:hidden}.g-checkbox__control{border:none;cursor:inherit;margin:0;opacity:0;outline:none;padding:0}.g-checkbox__control,.g-checkbox__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;position:absolute;width:100%}.g-checkbox__outline{border-radius:4px;pointer-events:none}.g-checkbox__control:focus-visible+.g-checkbox__outline{outline:2px solid var(--g-color-line-focus)}.g-checkbox_size_m .g-checkbox__icon-svg_type_tick{height:10px;width:8px}.g-checkbox_size_m .g-checkbox__icon-svg_type_dash{height:12px;width:12px}.g-checkbox_size_m .g-checkbox__indicator{height:14px;width:14px}.g-checkbox_size_l .g-checkbox__icon-svg_type_tick{height:9px;width:11px}.g-checkbox_size_l .g-checkbox__icon-svg_type_dash{height:15px;width:15px}.g-checkbox_size_l .g-checkbox__indicator{height:17px;width:17px}.g-checkbox:hover .g-checkbox__indicator:before{border-color:var(--g-color-line-generic-accent-hover)}.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);border:#0000}.g-checkbox_checked .g-checkbox__icon,.g-checkbox_indeterminate .g-checkbox__icon{color:var(--g-color-text-brand-contrast);transform:translateX(0);visibility:visible}.g-checkbox_disabled .g-checkbox__indicator:before{background-color:var(--g-color-base-generic-accent-disabled);border:#0000}.g-checkbox_disabled.g-checkbox_checked .g-checkbox__indicator:before,.g-checkbox_disabled.g-checkbox_indeterminate .g-checkbox__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.g-tree-select{display:inline-block;max-width:100%}.g-tree-select_width_max{width:100%}.g-tree-select__popup{overflow:hidden;padding:4px 0}.g-tree-select__popup_size_s{border-radius:var(--g-list-container-border-radius,5px)}.g-tree-select__popup_size_m{border-radius:var(--g-list-container-border-radius,6px)}.g-tree-select__popup_size_l{border-radius:var(--g-list-container-border-radius,8px)}.g-tree-select__popup_size_xl{border-radius:var(--g-list-container-border-radius,10px)}.g-tree-select__list{padding:0 4px}.g-list-item-expand-icon{flex-shrink:0}.g-list-item-view{align-items:center;display:flex;flex-grow:1;flex-shrink:0}.g-list-item-view__content{height:100%;width:100%}.g-list-item-view__main-content{display:grid;gap:var(--g-spacing-half,2px);width:100%}.g-list-item-view:hover.g-list-item-view_activeOnHover,.g-list-item-view_active{background:var(--g-color-base-simple-hover)}.g-list-item-view_clickable{cursor:pointer}.g-list-item-view_selected,.g-list-item-view_selected.g-list-item-view_active,.g-list-item-view_selected:hover.g-list-item-view_activeOnHover{background:var(--g-color-base-selection)}.g-list-item-view_dragging,.g-list-item-view_dragging.g-list-item-view_active,.g-list-item-view_dragging.g-list-item-view_selected{background:var(--g-color-base-simple-hover-solid);z-index:100001!important}.g-list-item-view_radius_s{border-radius:var(--g-list-item-border-radius,3px)}.g-list-item-view_radius_m{border-radius:var(--g-list-item-border-radius,5px)}.g-list-item-view_radius_l{border-radius:var(--g-list-item-border-radius,6px)}.g-list-item-view_radius_xl{border-radius:var(--g-list-item-border-radius,8px)}.g-list-item-view__slot{flex-shrink:0}.g-list-recursive-renderer{margin:0;padding:0}.g-list-container-view{box-sizing:border-box;outline:none;width:100%}.g-list-container-view_fixed-height{height:var(--g-list-container-height,300px)}.g-list-container-view:not(.g-list-container-view_fixed-height){overflow:auto}.g-inner-table-column-setup{display:inline-block}.g-inner-table-column-setup__controls{margin:var(--g-spacing-1) var(--g-spacing-1) 0}.g-inner-table-column-setup__filter-input{border-block-end:1px solid var(--g-color-line-generic);box-sizing:border-box;padding:0 var(--g-spacing-2) var(--g-spacing-1)}.g-inner-table-column-setup__empty-placeholder{padding:var(--g-spacing-2)}.g-table-column-setup__status{color:var(--g-color-text-secondary);margin-inline-start:5px}.gc-help-popover__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.gc-help-popover__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.json-inspector,.json-inspector__selection{font:14px/1.4 Consolas,monospace}.json-inspector__leaf{padding-left:10px}.json-inspector__line{cursor:default;display:block;position:relative}.json-inspector__line:after{bottom:0;content:"";left:-200px;pointer-events:none;position:absolute;right:-50px;top:0;z-index:-1}.json-inspector__line:hover:after{background:#0000000f}.json-inspector__leaf_composite>.json-inspector__line{cursor:pointer}.json-inspector__flatpath,.json-inspector__radio{display:none}.json-inspector__value{margin-left:5px}.json-inspector__search{margin:0 10px 10px 0;min-width:300px;padding:2px}.json-inspector__key{color:#505050}.json-inspector__not-found,.json-inspector__value_helper,.json-inspector__value_null{color:#b0b0b0}.json-inspector__value_string{color:#798953}.json-inspector__value_boolean{color:#75b5aa}.json-inspector__value_number{color:#d28445}.json-inspector__hl{background:#ff0;border-radius:2px;box-shadow:0 -1px 0 2px #ff0}.json-inspector__show-original{color:#666;cursor:pointer;display:inline-block;padding:0 6px}.json-inspector__show-original:hover{color:#111}.json-inspector__show-original:before{content:"⥂"}.json-inspector__show-original:hover:after{content:" expand"}.gc-definition-list__list{margin:0}.gc-definition-list__group-title{margin-block-end:var(--g-spacing-3)}.gc-definition-list__group-title:not(:first-of-type){margin-block-start:var(--g-spacing-5)}.gc-definition-list__item{align-items:baseline;display:flex;gap:var(--g-spacing-1)}.gc-definition-list__item+.gc-definition-list__item{margin-block-start:var(--g-spacing-4)}.gc-definition-list__item_grouped+.gc-definition-list__item_grouped{margin-block-start:var(--g-spacing-3)}.gc-definition-list_margin:not(:first-of-type){margin-block-start:var(--g-spacing-5)}.gc-definition-list__term-container{align-items:baseline;display:flex;flex:0 0 auto;max-width:300px;overflow:hidden;position:relative;width:300px}.gc-definition-list__term-wrapper{color:var(--g-color-text-secondary);flex:0 1 auto;overflow:hidden;position:relative;text-overflow:ellipsis;white-space:nowrap}.gc-definition-list__term-container_multiline .gc-definition-list__term-wrapper{white-space:unset}.gc-definition-list__term-container_multiline .gc-definition-list__item-note-tooltip{position:absolute}.gc-definition-list__dots{border-block-end:1px dotted var(--g-color-line-generic-active);box-sizing:border-box;flex:1 0 auto;margin:0 2px;min-width:40px}.gc-definition-list__dots_with-note{margin-inline-start:15px;min-width:25px}.gc-definition-list__definition{flex:0 1 auto;margin:0}.gc-definition-list_responsive .gc-definition-list__term-container{flex:1 0 auto}.gc-definition-list__copy-container{align-items:center;display:inline-flex;margin-inline-end:calc(var(--g-spacing-7)*-1);padding-inline-end:var(--g-spacing-7);position:relative}.gc-definition-list__copy-container:hover .gc-definition-list__copy-button{opacity:1}.gc-definition-list__copy-container_icon-inside{margin-inline-end:unset;padding-inline-end:unset}.gc-definition-list__copy-container_icon-inside .gc-definition-list__copy-button{inset-block-start:0}.gc-definition-list__copy-button{display:inline-block;inset-inline-end:0;margin-inline-start:10px;opacity:0;position:absolute}.gc-definition-list__copy-button:focus-visible{opacity:1}.gc-definition-list_vertical .gc-definition-list__term-container{flex:1 0 auto}.gc-definition-list_vertical .gc-definition-list__item{flex-direction:column;gap:var(--g-spacing-half)}.gc-definition-list_vertical .gc-definition-list__item+.gc-definition-list__item{margin-block-start:var(--g-spacing-3)}.gc-definition-list_vertical .gc-definition-list__group-title:not(:first-of-type),.gc-definition-list_vertical .gc-definition-list_margin:not(:first-of-type){margin-block-start:var(--g-spacing-8)}.chartkit-loader{align-items:center;display:flex;justify-content:center}.chartkit,.chartkit-loader{height:100%;width:100%}.chartkit_mobile .chartkit-scrollable-node{max-height:3000px}.chartkit-theme_common{--highcarts-navigator-border:var(--g-color-line-generic);--highcarts-navigator-track:var(--g-color-base-generic);--highcarts-navigator-body:var(--g-color-scroll-handle);--highcharts-series-border:var(--g-color-base-background);--highcharts-grid-line:var(--g-color-line-generic);--highcharts-axis-line:var(--g-color-line-generic);--highcharts-tick:var(--g-color-line-generic);--highcharts-title:var(--g-color-text-primary);--highcharts-axis-labels:var(--g-color-text-secondary);--highcharts-data-labels:var(--g-color-text-secondary);--highcharts-plot-line-label:var(--g-color-text-secondary);--highcharts-legend-item:var(--g-color-text-secondary);--highcharts-legend-item-hover:var(--g-color-text-primary);--highcharts-legend-item-hidden:var(--g-color-text-hint);--highcharts-floating-bg:var(--g-color-infographics-tooltip-bg);--highcharts-tooltip-text:var(--g-color-text-primary);--highcharts-tooltip-bg:var(--highcharts-floating-bg);--highcharts-tooltip-alternate-bg:var(--g-color-base-generic);--highcharts-tooltip-text-complementary:var(--g-color-text-secondary);--highcharts-holiday-band:var(--g-color-base-generic)}.ydb-tree-view{--ydb-tree-view-level:0;font-size:13px;line-height:18px}.ydb-tree-view,.ydb-tree-view *{box-sizing:border-box}.ydb-tree-view__item{align-items:center;border-bottom:1px solid var(--g-color-line-generic-solid);cursor:pointer;display:flex;height:24px;padding-left:calc(24px*var(--ydb-tree-view-level));padding-right:3px}.ydb-tree-view__item:hover{background-color:var(--g-color-base-simple-hover)}.ydb-tree-view__item:hover .ydb-tree-view__actions{display:flex}.ydb-tree-view__item_active{background-color:var(--g-color-base-selection);font-weight:700}.ydb-tree-view__item_active:hover{background-color:var(--g-color-base-selection-hover)}.ydb-tree-view__content{align-items:center;display:flex;flex-grow:1;overflow:hidden}.ydb-tree-view__icon{align-items:center;color:var(--g-color-text-hint);display:flex;flex-shrink:0;height:24px;justify-content:center;width:24px}.ydb-tree-view__icon svg{display:block}.ydb-tree-view__text{flex-grow:1;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.ydb-tree-view__actions{align-items:center;display:none;margin-left:6px}.ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%;border:none;cursor:pointer;flex-shrink:0;height:24px;padding:0;width:24px}.g-root_theme_dark .ydb-tree-view__arrow{background:url('data:image/svg+xml;utf8,') no-repeat 50%}.ydb-tree-view__arrow:focus-visible{outline:2px solid var(--g-color-line-focus)}.ydb-tree-view__arrow:not(.ydb-tree-view__arrow_collapsed){transform:rotate(90deg)}.ydb-tree-view__arrow_hidden{visibility:hidden}.ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:24px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:48px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:72px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:96px}.ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view .ydb-tree-view__item{padding-left:120px}.g-card{--_--background-color:#0000;--_--border-color:#0000;--_--border-width:0;--_--box-shadow:none;background-color:var(--g-card-background-color,var(--_--background-color));border:var(--g-card-border-width,var(--_--border-width)) solid var(--g-card-border-color,var(--_--border-color));border-radius:var(--g-card-border-radius,var(--_--border-radius));box-shadow:var(--g-card-box-shadow,var(--_--box-shadow));box-sizing:border-box;outline:none}.g-card_theme_normal{--_--border-color:var(--g-color-line-generic);--_--background-color:var(--g-color-base-generic)}.g-card_theme_info{--_--border-color:var(--g-color-line-info);--_--background-color:var(--g-color-base-info-light)}.g-card_theme_success{--_--border-color:var(--g-color-line-positive);--_--background-color:var(--g-color-base-positive-light)}.g-card_theme_warning{--_--border-color:var(--g-color-line-warning);--_--background-color:var(--g-color-base-warning-light)}.g-card_theme_danger{--_--border-color:var(--g-color-line-danger);--_--background-color:var(--g-color-base-danger-light)}.g-card_theme_utility{--_--border-color:var(--g-color-line-utility);--_--background-color:var(--g-color-base-utility-light)}.g-card_view_clear,.g-card_view_outlined{--_--background-color:#0000}.g-card_view_outlined{--_--border-width:1px}.g-card_type_action{--_--background-color:var(--g-color-base-float);--_--box-shadow:0px 1px 5px var(--g-color-sfx-shadow)}.g-card_type_action:after{border-radius:var(--g-card-border-radius,var(--_--border-radius));inset:0;pointer-events:none;position:absolute}.g-card_type_action.g-card_clickable{cursor:pointer;position:relative}.g-card_type_action.g-card_clickable:hover{--_--box-shadow:0px 3px 10px var(--g-color-sfx-shadow)}.g-card_type_action.g-card_clickable:focus-visible:after{content:"";outline:2px solid var(--g-color-line-focus)}.g-card_type_selection{--_--border-width:1px;--_--border-color:var(--g-color-line-generic);position:relative}.g-card_type_selection:before{inset:-1px}.g-card_type_selection:after,.g-card_type_selection:before{border-radius:var(--g-card-border-radius,var(--_--border-radius));pointer-events:none;position:absolute}.g-card_type_selection:after{inset:0}.g-card_type_selection.g-card_clickable{cursor:pointer}.g-card_type_selection.g-card_clickable:hover{--_--border-color:#0000}.g-card_type_selection.g-card_clickable:hover:not(.g-card_selected):before{border:2px solid var(--g-color-line-brand);content:"";opacity:.5}.g-card_type_selection.g-card_clickable:hover:focus-visible:before{border-color:#0000}.g-card_type_selection.g-card_clickable:focus-visible:after{content:"";outline:2px solid var(--g-color-line-focus)}.g-card_type_selection.g-card_selected:not(.g-card_disabled){--_--border-color:#0000}.g-card_type_selection.g-card_selected:not(.g-card_disabled):before{border:2px solid var(--g-color-line-brand);content:""}.g-card_type_selection.g-card_view_clear{--_--border-color:#0000}.g-card_type_container.g-card_view_raised{--_--background-color:var(--g-color-base-float)}.g-card_type_container.g-card_view_raised.g-card_size_m{--_--box-shadow:0px 1px 5px var(--g-color-sfx-shadow)}.g-card_type_container.g-card_view_raised.g-card_size_l{--_--box-shadow:0px 1px 6px var(--g-color-sfx-shadow-light),1px 3px 13px var(--g-color-sfx-shadow-light)}.g-card_size_m{--_--border-radius:8px}.g-card_size_l{--_--border-radius:16px}.g-date-relative-range-date-picker-control__input{caret-color:#0000}.g-date-relative-range-date-picker-control__input_mobile{pointer-events:none}.g-date-relative-range-date-picker-control__mobile-trigger{--_--g-date-mobile-trigger-clear-width:0px;--_--g-date-mobile-trigger-errors-width:0px;--_--g-date-mobile-trigger-button-width:24px;inset:0;inset-inline-end:calc(var(--g-spacing-2) + var(--_--g-date-mobile-trigger-button-width) + var(--_--g-date-mobile-trigger-clear-width) + var(--_--g-date-mobile-trigger-errors-width));opacity:0;position:absolute}.g-date-relative-range-date-picker-control__mobile-trigger_size_s{--_--g-date-mobile-trigger-button-width:20px}.g-date-relative-range-date-picker-control__mobile-trigger_size_l{--_--g-date-mobile-trigger-button-width:28px}.g-date-relative-range-date-picker-control__mobile-trigger_size_xl{--_--g-date-mobile-trigger-button-width:36px}.g-date-relative-range-date-picker-control__mobile-trigger_has-clear{--_--g-date-mobile-trigger-clear-width:calc(var(--_--g-date-mobile-trigger-button-width) + 2px)}.g-date-relative-range-date-picker-control__mobile-trigger_has-errors{--_--g-date-mobile-trigger-errors-width:calc(var(--_--g-date-mobile-trigger-button-width) + 2px)}.g-date-relative-range-date-picker-presets-doc__button{--g-button-background-color-hover:#0000}.g-date-relative-range-date-picker-presets-doc__content{--g-popover-max-width:"none"}.g-date-relative-range-date-picker-presets-doc__table_size_xl{font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-date-relative-range-date-picker-presets-doc__table>table{width:100%}.g-table,.g-table__scroll-container{overflow:auto;position:relative}.g-table__scroll-container{-ms-overflow-style:none;scrollbar-width:none}.g-table__scroll-container::-webkit-scrollbar{display:none}.g-table__horizontal-scroll-bar{margin-block-start:-1px;overflow-x:auto}.g-table__horizontal-scroll-bar-inner{height:1px;position:relative}.g-table__horizontal-scroll-bar-inner:before{background-color:#ffffff03;content:"";height:1px;inset-block-start:0;inset-inline-start:0;position:absolute;width:1px}.g-table__horizontal-scroll-bar_sticky-horizontal-scroll{position:sticky;z-index:3}.g-table__table{border-collapse:initial;border-spacing:0}.g-table__table_width_max{width:100%}.g-table__cell{border-block-end:1px solid var(--g-color-line-generic);box-sizing:initial;line-height:18px;overflow-wrap:break-word;padding:11px var(--g-spacing-2) 10px;text-align:start}.g-table__cell:first-child{padding-inline-start:0}.g-table__cell:last-child{padding-inline-end:0}.g-table__cell:not(.g-table__cell_word-wrap){overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-table__cell_align_center{text-align:center}.g-table__cell_align_end{text-align:end}.g-table .g-table__cell_sticky_end,.g-table .g-table__cell_sticky_start{background:var(--g-color-base-background);position:sticky;z-index:2}.g-table__cell_border_right{border-inline-end:1px solid var(--g-color-line-generic)}.g-table__cell_edge-padding:first-child{padding-inline-start:var(--g-spacing-3)}.g-table__cell_edge-padding:last-child{padding-inline-end:var(--g-spacing-3)}.g-table__row_vertical-align_top{vertical-align:top}.g-table__row_vertical-align_middle{vertical-align:middle}.g-table__row_empty .g-table__cell{text-align:center}.g-table__body .g-table__row:last-child .g-table__cell{border-block-end-color:#0000}.g-table__head .g-table__cell{font-weight:var(--g-text-accent-font-weight)}.g-table__body .g-table__row_interactive:hover{background-color:var(--g-color-base-simple-hover-solid);cursor:pointer}.g-table__body .g-table__row_interactive:hover .g-table__cell_sticky_end,.g-table__body .g-table__row_interactive:hover .g-table__cell_sticky_start{background:var(--g-color-base-simple-hover-solid)}.g-table__body .g-table__row_disabled{opacity:.3}.g-table_with-primary .g-table__body .g-table__cell{color:var(--g-color-text-secondary)}.g-table_with-primary .g-table__body .g-table__cell_primary{color:var(--g-color-text-primary)}.g-table_with-sticky-scroll{overflow:visible}.g-date-relative-range-date-picker-presets{--g-list-item-padding:0 var(--_--g-date-picker-presets-padding,0)}.g-date-relative-range-date-picker-presets__tabs{--g-tabs-border-width:0;align-items:center;box-shadow:inset 0 -1px var(--g-color-line-generic);display:flex;gap:var(--g-spacing-2);padding-inline:var(--_--g-date-picker-presets-padding,0)}.g-date-relative-range-date-picker-presets__list-container{outline:none}.g-date-relative-range-date-picker-presets__doc{margin-inline-start:auto}.g-date-relative-range-date-picker-presets__content{height:128px;overflow:auto}.g-date-relative-range-date-picker-presets_size_l .g-date-relative-range-date-picker-presets__content{height:144px}.g-date-relative-range-date-picker-presets_size_xl .g-date-relative-range-date-picker-presets__content{font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);height:162px;line-height:var(--g-text-body-2-line-height)}.g-date-relative-range-date-picker-zones__control{--g-button-background-color-hover:#0000}.g-date-relative-range-date-picker-dialog__content{--_--popup-content-padding:var(--g-spacing-2);--_--g-date-picker-presets-padding:var(--_--popup-content-padding);padding:var(--_--popup-content-padding)}.g-date-relative-range-date-picker-dialog__content_mobile{--_--popup-content-padding:var(--g-spacing-5)}.g-date-relative-range-date-picker-dialog__content:not(.g-date-relative-range-date-picker-dialog__content_mobile){width:310px}.g-date-relative-range-date-picker-dialog__content_size_xl:not(.g-date-relative-range-date-picker-dialog__content_mobile){width:380px}.g-date-relative-range-date-picker-dialog__pickers{display:flex;flex-direction:column;gap:var(--g-spacing-2)}.g-date-relative-range-date-picker-dialog__pickers .g-text-input__label{width:40px}.g-date-relative-range-date-picker-dialog__content_size_xl .g-date-relative-range-date-picker-dialog__pickers .g-text-input__label{width:50px}.g-date-relative-range-date-picker-dialog__apply{margin-block-start:var(--g-spacing-2)}.g-date-relative-range-date-picker-dialog__zone{border-block-start:1px solid var(--g-color-line-generic);margin-block:var(--g-spacing-2) calc(var(--_--popup-content-padding)*-1)}.g-date-relative-range-date-picker-dialog__presets,.g-date-relative-range-date-picker-dialog__zone{margin-inline:calc(var(--_--popup-content-padding)*-1)}.g-date-mobile-calendar{border:none;box-sizing:border-box;cursor:pointer;height:100%;inset-block-start:0;inset-inline-start:0;margin:0;min-width:100%;opacity:0;padding:0;position:absolute;z-index:1}.g-date-mobile-calendar::-webkit-calendar-picker-indicator{cursor:pointer;height:100%;inset-block-start:0;inset-inline-start:0;margin:0;min-width:100%;padding:0;position:absolute}.g-date-stub-button{display:inline-block;height:24px;position:relative;width:24px}.g-date-stub-button_size_xs{height:20px;width:20px}.g-date-stub-button_size_m{height:28px;width:28px}.g-date-stub-button_size_l{height:36px;width:36px}.g-date-stub-button__icon{align-items:center;color:var(--g-color-text-secondary);display:flex;inset:0;justify-content:center;position:absolute}.g-date-relative-date-picker{display:inline-flex;outline:none;position:relative}.g-date-relative-date-picker__input_mobile{pointer-events:none}.g-date-relative-date-picker__field{width:100%}.g-date-relative-date-picker__popup-content{outline:none}.g-date-relative-date-picker__time-field{width:100%}.g-date-relative-date-picker__time-field-wrapper{padding:10px}.g-date-calendar{--_--calendar-padding:var(--g-date-calendar-padding,8px);--_--calendar-day-size:var(--g-date-calendar-day-size,28px);--_--calendar-days-gap:var(--g-date-calendar-days-gap,2px);--_--calendar-width:calc(var(--_--calendar-day-size)*7 + var(--_--calendar-days-gap)*6 + var(--_--calendar-padding)*2);--_--calendar-grid-height:calc(var(--_--calendar-day-size)*7 + var(--_--calendar-days-gap)*5 + var(--_--calendar-padding));display:inline-block;width:var(--_--calendar-width)}.g-date-calendar_size_l{--g-date-calendar-day-size:36px}.g-date-calendar_size_xl{--g-date-calendar-day-size:42px;font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-date-calendar__header{display:flex;padding:var(--_--calendar-padding) var(--_--calendar-padding) 0}.g-date-calendar__years-label{color:var(--g-color-text-secondary)}.g-date-calendar__controls{margin-inline-start:auto}.g-date-calendar__control-icon{transform:scaleX(var(--g-flow-direction))}.g-date-calendar__grid{height:var(--_--calendar-grid-height);overflow:hidden;position:relative;-webkit-user-select:none;user-select:none;width:100%}.g-date-calendar__content{box-sizing:border-box;display:grid;grid-template-rows:var(--_--calendar-day-size) 1fr;height:100%;inset-block-start:0;inset-inline-start:0;padding:0 var(--_--calendar-padding) var(--_--calendar-padding);position:absolute;width:100%}@keyframes calendar-forward{0%{transform:translateX(0)}to{transform:translateX(100%)}}@keyframes calendar-backward{0%{transform:translateX(0)}to{transform:translateX(-100%)}}@keyframes calendar-zoom-in-showing{0%{opacity:0;transform:scale(2)}to{opacity:1;transform:scale(1)}}@keyframes calendar-zoom-in-hiding{0%{opacity:1;transform:scale(1)}to{opacity:0;transform:scale(0)}}@keyframes calendar-zoom-out-showing{0%{opacity:0;transform:scale(0)}to{opacity:1;transform:scale(1)}}@keyframes calendar-zoom-out-hiding{0%{opacity:1;transform:scale(1)}to{opacity:0;transform:scale(2)}}.g-date-calendar__content_animation_forward{animation:calendar-forward .25s ease forwards;transform:translateX(-100%)}.g-date-calendar__content_animation_forward.g-date-calendar__current-state{inset-inline-start:calc(var(--g-flow-direction)*-100%)}.g-date-calendar__content_animation_backward{animation:calendar-backward .25s ease forwards;transform:translateX(0)}.g-date-calendar__content_animation_backward.g-date-calendar__current-state{inset-inline-start:calc(var(--g-flow-direction)*100%)}.g-date-calendar__content_animation_zoom-in{transform:scale()}.g-date-calendar__content_animation_zoom-in.g-date-calendar__previous-state{animation:calendar-zoom-in-hiding .25s ease forwards}.g-date-calendar__content_animation_zoom-in.g-date-calendar__current-state{animation:calendar-zoom-in-showing .25s ease forwards}.g-date-calendar__content_animation_zoom-out{transform:scale()}.g-date-calendar__content_animation_zoom-out.g-date-calendar__current-state{animation:calendar-zoom-out-showing .25s ease forwards}.g-date-calendar__content_animation_zoom-out.g-date-calendar__previous-state{animation:calendar-zoom-out-hiding .25s ease forwards}@media (update:slow),screen and (prefers-reduced-motion:reduce){.g-date-calendar__content[class]{animation-duration:.001ms}}.g-date-calendar__grid-rowgroup{display:grid;gap:var(--_--calendar-days-gap)}.g-date-calendar__grid-rowgroup_mode_months,.g-date-calendar__grid-rowgroup_mode_quarters,.g-date-calendar__grid-rowgroup_mode_years{grid-row:1/-1;padding:12px 0 0}.g-date-calendar__grid-rowgroup-header{align-self:center}.g-date-calendar__grid-row{display:grid;gap:var(--_--calendar-days-gap);grid-auto-columns:1fr;grid-auto-flow:column}.g-date-calendar__weekday{align-items:center;display:flex;height:100%;justify-content:center;width:100%}.g-date-calendar__weekday_weekend{color:var(--g-color-text-danger)}.g-date-calendar__button{align-items:center;border-radius:4px;cursor:pointer;display:flex;font-weight:var(--g-text-subheader-font-weight);height:100%;justify-content:center;outline:none;position:relative;width:100%}.g-date-calendar__button:focus{box-shadow:0 0 0 2px var(--g-color-line-misc)}.g-date-calendar__button:focus:not(:focus-visible){box-shadow:none}.g-date-calendar__button:hover{background-color:var(--g-color-base-generic)}.g-date-calendar__button_selected[class]{background-color:var(--g-color-base-selection)}.g-date-calendar__button_selected.g-date-calendar__button_selection-end,.g-date-calendar__button_selected.g-date-calendar__button_selection-start{background-color:var(--g-color-base-brand)}.g-date-calendar__button_weekend{color:var(--g-color-text-danger)}.g-date-calendar__button_out-of-boundary{font-weight:var(--g-text-body-font-weight);opacity:.6}.g-date-calendar__button_current:before{background-color:currentColor;border-radius:50%;content:"";display:block;height:4px;inset-block-start:50%;position:absolute;transform:translateY(8px);width:4px}.g-date-calendar__button_disabled{font-weight:var(--g-text-body-font-weight);opacity:.6;pointer-events:none}.g-date-calendar__button_unavailable:not(.g-date-calendar__button_disabled){background-color:var(--g-color-base-generic);cursor:default;font-weight:var(--g-text-body-font-weight);opacity:.5}.g-date-date-field{display:inline-block;width:auto}.g-date-relative-range-date-picker{display:inline-flex;position:relative}.g-date-relative-range-date-picker__value-label{display:flex;width:100%}.g-date-relative-range-date-picker__value-label>div{flex:1 0}.g-date-relative-range-date-picker__value-label-content{display:flex;flex-direction:column}.g-date-relative-range-date-picker__value-label-tooltip{--g-popover-max-width:"none"}.g-date-relative-range-date-picker__value-label-item,.g-date-relative-range-date-picker__value-label-to,.g-date-relative-range-date-picker__value-label-tz{text-align:center}.g-date-relative-range-date-picker__value-label-tz{color:var(--g-color-text-hint);margin-block-start:5px}.g-tooltip[class]{--g-popup-border-width:0}.g-tooltip[class]>div{animation-duration:1ms;box-shadow:0 1px 5px 0 #00000026;box-sizing:border-box;max-width:360px;padding:4px 8px}.g-tooltip__content{-webkit-box-orient:vertical;-ms-box-orient:vertical;-webkit-line-clamp:20;-moz-line-clamp:20;-ms-line-clamp:20;display:-webkit-box;overflow:hidden;text-overflow:ellipsis}.g-spin{animation:g-spin 1s linear infinite;backface-visibility:hidden;display:inline-block}.g-spin__inner{border:2px solid var(--g-color-line-brand);border-end-end-radius:25px;border-inline-start:none;border-start-end-radius:25px;box-sizing:border-box;height:100%;margin-inline-start:50%;width:50%}.g-spin_size_xs{height:16px;width:16px}.g-spin_size_s{height:24px;width:24px}.g-spin_size_m{height:28px;width:28px}.g-spin_size_l{height:32px;width:32px}.g-spin_size_xl{height:36px;width:36px}@keyframes g-spin{0%{transform:rotate(0deg)}to{transform:rotate(1turn)}}.g-alert_corners_square{--g-card-border-radius:0}.g-alert__text-content{width:100%}.g-alert__actions_minContent{width:min-content}.g-alert__close-btn{flex-shrink:0}.monaco-aria-container{left:-999em;position:absolute}.monaco-editor .selection-anchor{background-color:#007acc;width:2px!important}.monaco-editor .bracket-match{background-color:var(--vscode-editorBracketMatch-background);border:1px solid var(--vscode-editorBracketMatch-border);box-sizing:border-box}.inline-editor-progress-decoration{display:inline-block;height:1em;width:1em}.inline-progress-widget{align-items:center;display:flex!important;justify-content:center}.inline-progress-widget .icon{font-size:80%!important}.inline-progress-widget:hover .icon{animation:none;font-size:90%!important}.inline-progress-widget:hover .icon:before{content:var(--vscode-icon-x-content);font-family:var(--vscode-icon-x-font-family)}.monaco-editor .monaco-editor-overlaymessage{padding-bottom:8px;z-index:10000}.monaco-editor .monaco-editor-overlaymessage.below{padding-bottom:0;padding-top:8px;z-index:10000}@keyframes fadeIn{0%{opacity:0}to{opacity:1}}.monaco-editor .monaco-editor-overlaymessage.fadeIn{animation:fadeIn .15s ease-out}@keyframes fadeOut{0%{opacity:1}to{opacity:0}}.monaco-editor .monaco-editor-overlaymessage.fadeOut{animation:fadeOut .1s ease-out}.monaco-editor .monaco-editor-overlaymessage .message{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-inputValidation-infoBorder);border-radius:3px;color:var(--vscode-editorHoverWidget-foreground);padding:2px 4px}.monaco-editor .monaco-editor-overlaymessage .message p{margin-block:0}.monaco-editor .monaco-editor-overlaymessage .message a{color:var(--vscode-textLink-foreground)}.monaco-editor .monaco-editor-overlaymessage .message a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor.hc-black .monaco-editor-overlaymessage .message,.monaco-editor.hc-light .monaco-editor-overlaymessage .message{border-width:2px}.monaco-editor .monaco-editor-overlaymessage .anchor{border:8px solid #0000;height:0!important;left:2px;position:absolute;width:0!important;z-index:1000}.monaco-editor .monaco-editor-overlaymessage .anchor.top{border-bottom-color:var(--vscode-inputValidation-infoBorder)}.monaco-editor .monaco-editor-overlaymessage .anchor.below{border-top-color:var(--vscode-inputValidation-infoBorder)}.monaco-editor .monaco-editor-overlaymessage.below .anchor.below,.monaco-editor .monaco-editor-overlaymessage:not(.below) .anchor.top{display:none}.monaco-editor .monaco-editor-overlaymessage.below .anchor.top{display:inherit;top:-8px}.monaco-editor .rendered-markdown kbd{background-color:var(--vscode-keybindingLabel-background);border-color:var(--vscode-keybindingLabel-border);border-bottom-color:var(--vscode-keybindingLabel-bottomBorder);border-radius:3px;border-style:solid;border-width:1px;box-shadow:inset 0 -1px 0 var(--vscode-widget-shadow);color:var(--vscode-keybindingLabel-foreground);padding:1px 3px;vertical-align:middle}.rendered-markdown li:has(input[type=checkbox]){list-style-type:none}.monaco-text-button{align-items:center;border:1px solid var(--vscode-button-border,#0000);border-radius:2px;box-sizing:border-box;cursor:pointer;display:flex;justify-content:center;line-height:18px;padding:4px;text-align:center;width:100%}.monaco-text-button:focus{outline-offset:2px!important}.monaco-text-button:hover{text-decoration:none!important}.monaco-button.disabled,.monaco-button.disabled:focus{cursor:default;opacity:.4!important}.monaco-text-button .codicon{color:inherit!important;margin:0 .2em}.monaco-text-button.monaco-text-button-with-short-label{flex-direction:row;flex-wrap:wrap;height:28px;overflow:hidden;padding:0 4px}.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label{flex-basis:100%}.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label-short{flex-grow:1;overflow:hidden;width:0}.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label,.monaco-text-button.monaco-text-button-with-short-label>.monaco-button-label-short{align-items:center;display:flex;font-style:inherit;font-weight:400;justify-content:center;padding:4px 0}.monaco-button-dropdown{cursor:pointer;display:flex}.monaco-button-dropdown.disabled{cursor:default}.monaco-button-dropdown>.monaco-button:focus{outline-offset:-1px!important}.monaco-button-dropdown.disabled>.monaco-button-dropdown-separator,.monaco-button-dropdown.disabled>.monaco-button.disabled,.monaco-button-dropdown.disabled>.monaco-button.disabled:focus{opacity:.4!important}.monaco-button-dropdown>.monaco-button.monaco-text-button{border-right-width:0!important}.monaco-button-dropdown .monaco-button-dropdown-separator{cursor:default;padding:4px 0}.monaco-button-dropdown .monaco-button-dropdown-separator>div{height:100%;width:1px}.monaco-button-dropdown>.monaco-button.monaco-dropdown-button{align-items:center;border:1px solid var(--vscode-button-border,#0000);border-left-width:0!important;border-radius:0 2px 2px 0;display:flex}.monaco-button-dropdown>.monaco-button.monaco-text-button{border-radius:2px 0 0 2px}.monaco-description-button{align-items:center;display:flex;flex-direction:column;margin:4px 5px}.monaco-description-button .monaco-button-description{font-size:11px;font-style:italic;padding:4px 20px}.monaco-description-button .monaco-button-description,.monaco-description-button .monaco-button-label{align-items:center;display:flex;justify-content:center}.monaco-description-button .monaco-button-description>.codicon,.monaco-description-button .monaco-button-label>.codicon{color:inherit!important;margin:0 .2em}.monaco-button-dropdown.default-colors>.monaco-button,.monaco-button.default-colors{background-color:var(--vscode-button-background);color:var(--vscode-button-foreground)}.monaco-button-dropdown.default-colors>.monaco-button:hover,.monaco-button.default-colors:hover{background-color:var(--vscode-button-hoverBackground)}.monaco-button-dropdown.default-colors>.monaco-button.secondary,.monaco-button.default-colors.secondary{background-color:var(--vscode-button-secondaryBackground);color:var(--vscode-button-secondaryForeground)}.monaco-button-dropdown.default-colors>.monaco-button.secondary:hover,.monaco-button.default-colors.secondary:hover{background-color:var(--vscode-button-secondaryHoverBackground)}.monaco-button-dropdown.default-colors .monaco-button-dropdown-separator{background-color:var(--vscode-button-background);border-bottom:1px solid var(--vscode-button-border);border-top:1px solid var(--vscode-button-border)}.monaco-button-dropdown.default-colors .monaco-button.secondary+.monaco-button-dropdown-separator{background-color:var(--vscode-button-secondaryBackground)}.monaco-button-dropdown.default-colors .monaco-button-dropdown-separator>div{background-color:var(--vscode-button-separator)}.post-edit-widget{background-color:var(--vscode-editorWidget-background);border:1px solid var(--vscode-widget-border,#0000);border-radius:4px;box-shadow:0 0 8px 2px var(--vscode-widget-shadow);overflow:hidden}.post-edit-widget .monaco-button{border:none;border-radius:0;padding:2px}.post-edit-widget .monaco-button:hover{background-color:var(--vscode-button-secondaryHoverBackground)!important}.post-edit-widget .monaco-button .codicon{margin:0}@font-face{font-display:block;font-family:codicon;src:url(../../static/media/codicon.f6283f7ccaed1249d9eb.ttf) format("truetype")}.codicon[class*=codicon-]{-webkit-font-smoothing:antialiased;-moz-osx-font-smoothing:grayscale;display:inline-block;font:normal normal normal 16px/1 codicon;text-align:center;text-decoration:none;text-rendering:auto;text-transform:none;user-select:none;-webkit-user-select:none}.codicon-wrench-subaction{opacity:.5}@keyframes codicon-spin{to{transform:rotate(1turn)}}.codicon-gear.codicon-modifier-spin,.codicon-loading.codicon-modifier-spin,.codicon-notebook-state-executing.codicon-modifier-spin,.codicon-sync.codicon-modifier-spin{animation:codicon-spin 1.5s steps(30) infinite}.codicon-modifier-disabled{opacity:.4}.codicon-loading,.codicon-tree-item-loading:before{animation-duration:1s!important;animation-timing-function:cubic-bezier(.53,.21,.29,.67)!important}.monaco-editor .codicon.codicon-symbol-array,.monaco-workbench .codicon.codicon-symbol-array{color:var(--vscode-symbolIcon-arrayForeground)}.monaco-editor .codicon.codicon-symbol-boolean,.monaco-workbench .codicon.codicon-symbol-boolean{color:var(--vscode-symbolIcon-booleanForeground)}.monaco-editor .codicon.codicon-symbol-class,.monaco-workbench .codicon.codicon-symbol-class{color:var(--vscode-symbolIcon-classForeground)}.monaco-editor .codicon.codicon-symbol-method,.monaco-workbench .codicon.codicon-symbol-method{color:var(--vscode-symbolIcon-methodForeground)}.monaco-editor .codicon.codicon-symbol-color,.monaco-workbench .codicon.codicon-symbol-color{color:var(--vscode-symbolIcon-colorForeground)}.monaco-editor .codicon.codicon-symbol-constant,.monaco-workbench .codicon.codicon-symbol-constant{color:var(--vscode-symbolIcon-constantForeground)}.monaco-editor .codicon.codicon-symbol-constructor,.monaco-workbench .codicon.codicon-symbol-constructor{color:var(--vscode-symbolIcon-constructorForeground)}.monaco-editor .codicon.codicon-symbol-enum,.monaco-editor .codicon.codicon-symbol-value,.monaco-workbench .codicon.codicon-symbol-enum,.monaco-workbench .codicon.codicon-symbol-value{color:var(--vscode-symbolIcon-enumeratorForeground)}.monaco-editor .codicon.codicon-symbol-enum-member,.monaco-workbench .codicon.codicon-symbol-enum-member{color:var(--vscode-symbolIcon-enumeratorMemberForeground)}.monaco-editor .codicon.codicon-symbol-event,.monaco-workbench .codicon.codicon-symbol-event{color:var(--vscode-symbolIcon-eventForeground)}.monaco-editor .codicon.codicon-symbol-field,.monaco-workbench .codicon.codicon-symbol-field{color:var(--vscode-symbolIcon-fieldForeground)}.monaco-editor .codicon.codicon-symbol-file,.monaco-workbench .codicon.codicon-symbol-file{color:var(--vscode-symbolIcon-fileForeground)}.monaco-editor .codicon.codicon-symbol-folder,.monaco-workbench .codicon.codicon-symbol-folder{color:var(--vscode-symbolIcon-folderForeground)}.monaco-editor .codicon.codicon-symbol-function,.monaco-workbench .codicon.codicon-symbol-function{color:var(--vscode-symbolIcon-functionForeground)}.monaco-editor .codicon.codicon-symbol-interface,.monaco-workbench .codicon.codicon-symbol-interface{color:var(--vscode-symbolIcon-interfaceForeground)}.monaco-editor .codicon.codicon-symbol-key,.monaco-workbench .codicon.codicon-symbol-key{color:var(--vscode-symbolIcon-keyForeground)}.monaco-editor .codicon.codicon-symbol-keyword,.monaco-workbench .codicon.codicon-symbol-keyword{color:var(--vscode-symbolIcon-keywordForeground)}.monaco-editor .codicon.codicon-symbol-module,.monaco-workbench .codicon.codicon-symbol-module{color:var(--vscode-symbolIcon-moduleForeground)}.monaco-editor .codicon.codicon-symbol-namespace,.monaco-workbench .codicon.codicon-symbol-namespace{color:var(--vscode-symbolIcon-namespaceForeground)}.monaco-editor .codicon.codicon-symbol-null,.monaco-workbench .codicon.codicon-symbol-null{color:var(--vscode-symbolIcon-nullForeground)}.monaco-editor .codicon.codicon-symbol-number,.monaco-workbench .codicon.codicon-symbol-number{color:var(--vscode-symbolIcon-numberForeground)}.monaco-editor .codicon.codicon-symbol-object,.monaco-workbench .codicon.codicon-symbol-object{color:var(--vscode-symbolIcon-objectForeground)}.monaco-editor .codicon.codicon-symbol-operator,.monaco-workbench .codicon.codicon-symbol-operator{color:var(--vscode-symbolIcon-operatorForeground)}.monaco-editor .codicon.codicon-symbol-package,.monaco-workbench .codicon.codicon-symbol-package{color:var(--vscode-symbolIcon-packageForeground)}.monaco-editor .codicon.codicon-symbol-property,.monaco-workbench .codicon.codicon-symbol-property{color:var(--vscode-symbolIcon-propertyForeground)}.monaco-editor .codicon.codicon-symbol-reference,.monaco-workbench .codicon.codicon-symbol-reference{color:var(--vscode-symbolIcon-referenceForeground)}.monaco-editor .codicon.codicon-symbol-snippet,.monaco-workbench .codicon.codicon-symbol-snippet{color:var(--vscode-symbolIcon-snippetForeground)}.monaco-editor .codicon.codicon-symbol-string,.monaco-workbench .codicon.codicon-symbol-string{color:var(--vscode-symbolIcon-stringForeground)}.monaco-editor .codicon.codicon-symbol-struct,.monaco-workbench .codicon.codicon-symbol-struct{color:var(--vscode-symbolIcon-structForeground)}.monaco-editor .codicon.codicon-symbol-text,.monaco-workbench .codicon.codicon-symbol-text{color:var(--vscode-symbolIcon-textForeground)}.monaco-editor .codicon.codicon-symbol-type-parameter,.monaco-workbench .codicon.codicon-symbol-type-parameter{color:var(--vscode-symbolIcon-typeParameterForeground)}.monaco-editor .codicon.codicon-symbol-unit,.monaco-workbench .codicon.codicon-symbol-unit{color:var(--vscode-symbolIcon-unitForeground)}.monaco-editor .codicon.codicon-symbol-variable,.monaco-workbench .codicon.codicon-symbol-variable{color:var(--vscode-symbolIcon-variableForeground)}.monaco-editor .lightBulbWidget{align-items:center;display:flex;justify-content:center}.monaco-editor .lightBulbWidget:hover{cursor:pointer}.monaco-editor .lightBulbWidget.codicon-light-bulb,.monaco-editor .lightBulbWidget.codicon-lightbulb-sparkle{color:var(--vscode-editorLightBulb-foreground)}.monaco-editor .lightBulbWidget.codicon-lightbulb-autofix,.monaco-editor .lightBulbWidget.codicon-lightbulb-sparkle-autofix{color:var(--vscode-editorLightBulbAutoFix-foreground,var(--vscode-editorLightBulb-foreground))}.monaco-editor .lightBulbWidget.codicon-sparkle-filled{color:var(--vscode-editorLightBulbAi-foreground,var(--vscode-icon-foreground))}.monaco-editor .lightBulbWidget:before{position:relative;z-index:2}.monaco-editor .lightBulbWidget:after{content:"";display:block;height:100%;left:0;opacity:.3;position:absolute;top:0;width:100%;z-index:1}.monaco-editor .glyph-margin-widgets .cgmr[class*=codicon-gutter-lightbulb]{cursor:pointer;display:block}.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb,.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-sparkle{color:var(--vscode-editorLightBulb-foreground)}.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-aifix-auto-fix,.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-auto-fix{color:var(--vscode-editorLightBulbAutoFix-foreground,var(--vscode-editorLightBulb-foreground))}.monaco-editor .glyph-margin-widgets .cgmr.codicon-gutter-lightbulb-sparkle-filled{color:var(--vscode-editorLightBulbAi-foreground,var(--vscode-icon-foreground))}.monaco-list{height:100%;position:relative;white-space:nowrap;width:100%}.monaco-list.mouse-support{user-select:none;-webkit-user-select:none}.monaco-list>.monaco-scrollable-element{height:100%}.monaco-list-rows{height:100%;position:relative;width:100%}.monaco-list.horizontal-scrolling .monaco-list-rows{min-width:100%;width:auto}.monaco-list-row{box-sizing:border-box;overflow:hidden;position:absolute;width:100%}.monaco-list.mouse-support .monaco-list-row{cursor:pointer;touch-action:none}.monaco-list .monaco-scrollable-element>.scrollbar.vertical,.monaco-pane-view>.monaco-split-view2.vertical>.monaco-scrollable-element>.scrollbar.vertical{z-index:14}.monaco-list-row.scrolling{display:none!important}.monaco-list.element-focused,.monaco-list.selection-multiple,.monaco-list.selection-single{outline:0!important}.monaco-drag-image{border-radius:10px;display:inline-block;font-size:12px;padding:1px 7px;position:absolute;z-index:1000}.monaco-list-type-filter-message{box-sizing:border-box;height:100%;left:0;opacity:.7;padding:40px 1em 1em;pointer-events:none;position:absolute;text-align:center;top:0;white-space:normal;width:100%}.monaco-list-type-filter-message:empty{display:none}.monaco-scrollable-element>.scrollbar>.scra{cursor:pointer;font-size:11px!important}.monaco-scrollable-element>.visible{background:#0000;opacity:1;transition:opacity .1s linear;z-index:11}.monaco-scrollable-element>.invisible{opacity:0;pointer-events:none}.monaco-scrollable-element>.invisible.fade{transition:opacity .8s linear}.monaco-scrollable-element>.shadow{display:none;position:absolute}.monaco-scrollable-element>.shadow.top{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px inset;display:block;height:3px;left:3px;top:0;width:100%}.monaco-scrollable-element>.shadow.left{box-shadow:var(--vscode-scrollbar-shadow) 6px 0 6px -6px inset;display:block;height:100%;left:0;top:3px;width:3px}.monaco-scrollable-element>.shadow.top-left-corner{display:block;height:3px;left:0;top:0;width:3px}.monaco-scrollable-element>.shadow.top.left{box-shadow:var(--vscode-scrollbar-shadow) 6px 0 6px -6px inset}.monaco-scrollable-element>.scrollbar>.slider{background:var(--vscode-scrollbarSlider-background)}.monaco-scrollable-element>.scrollbar>.slider:hover{background:var(--vscode-scrollbarSlider-hoverBackground)}.monaco-scrollable-element>.scrollbar>.slider.active{background:var(--vscode-scrollbarSlider-activeBackground)}.monaco-select-box-dropdown-padding{--dropdown-padding-top:1px;--dropdown-padding-bottom:1px}.hc-black .monaco-select-box-dropdown-padding,.hc-light .monaco-select-box-dropdown-padding{--dropdown-padding-top:3px;--dropdown-padding-bottom:4px}.monaco-select-box-dropdown-container{box-sizing:border-box;display:none}.monaco-select-box-dropdown-container>.select-box-details-pane>.select-box-description-markdown *{margin:0}.monaco-select-box-dropdown-container>.select-box-details-pane>.select-box-description-markdown a:focus{outline:1px solid -webkit-focus-ring-color;outline-offset:-1px}.monaco-select-box-dropdown-container>.select-box-details-pane>.select-box-description-markdown code{font-family:var(--monaco-monospace-font);line-height:15px}.monaco-select-box-dropdown-container.visible{border-bottom-left-radius:3px;border-bottom-right-radius:3px;display:flex;flex-direction:column;overflow:hidden;text-align:left;width:1px}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container{align-self:flex-start;box-sizing:border-box;flex:0 0 auto;overflow:hidden;padding-bottom:var(--dropdown-padding-bottom);padding-left:1px;padding-right:1px;padding-top:var(--dropdown-padding-top);width:100%}.monaco-select-box-dropdown-container>.select-box-details-pane{padding:5px}.hc-black .monaco-select-box-dropdown-container>.select-box-dropdown-list-container{padding-bottom:var(--dropdown-padding-bottom);padding-top:var(--dropdown-padding-top)}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row{cursor:pointer}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.option-text{float:left;overflow:hidden;padding-left:3.5px;text-overflow:ellipsis;white-space:nowrap}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.option-detail{float:left;opacity:.7;overflow:hidden;padding-left:3.5px;text-overflow:ellipsis;white-space:nowrap}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.option-decorator-right{float:right;overflow:hidden;padding-right:10px;text-overflow:ellipsis;white-space:nowrap}.monaco-select-box-dropdown-container>.select-box-dropdown-list-container .monaco-list .monaco-list-row>.visually-hidden{height:1px;left:-10000px;overflow:hidden;position:absolute;top:auto;width:1px}.monaco-select-box-dropdown-container>.select-box-dropdown-container-width-control{align-self:flex-start;flex:1 1 auto;opacity:0}.monaco-select-box-dropdown-container>.select-box-dropdown-container-width-control>.width-control-div{max-height:0;overflow:hidden}.monaco-select-box-dropdown-container>.select-box-dropdown-container-width-control>.width-control-div>.option-text-width-control{padding-left:4px;padding-right:8px;white-space:nowrap}.monaco-select-box{border-radius:2px;cursor:pointer;width:100%}.monaco-select-box-dropdown-container{font-size:13px;font-weight:400;text-transform:none}.monaco-action-bar .action-item.select-container{cursor:default}.monaco-action-bar .action-item .monaco-select-box{cursor:pointer;min-height:18px;min-width:100px;padding:2px 23px 2px 8px}.mac .monaco-action-bar .action-item .monaco-select-box{border-radius:5px;font-size:11px}.monaco-action-bar{height:100%;white-space:nowrap}.monaco-action-bar .actions-container{align-items:center;display:flex;height:100%;margin:0 auto;padding:0;width:100%}.monaco-action-bar.vertical .actions-container{display:inline-block}.monaco-action-bar .action-item{align-items:center;cursor:pointer;display:block;justify-content:center;position:relative}.monaco-action-bar .action-item.disabled{cursor:default}.monaco-action-bar .action-item .codicon,.monaco-action-bar .action-item .icon{display:block}.monaco-action-bar .action-item .codicon{align-items:center;display:flex;height:16px;width:16px}.monaco-action-bar .action-label{border-radius:5px;display:flex;font-size:11px;padding:3px}.monaco-action-bar .action-item.disabled .action-label,.monaco-action-bar .action-item.disabled .action-label:before,.monaco-action-bar .action-item.disabled .action-label:hover{color:var(--vscode-disabledForeground)}.monaco-action-bar.vertical{text-align:left}.monaco-action-bar.vertical .action-item{display:block}.monaco-action-bar.vertical .action-label.separator{border-bottom:1px solid #bbb;display:block;margin-left:.8em;margin-right:.8em;padding-top:1px}.monaco-action-bar .action-item .action-label.separator{background-color:#bbb;cursor:default;height:16px;margin:5px 4px!important;min-width:1px;padding:0;width:1px}.secondary-actions .monaco-action-bar .action-label{margin-left:6px}.monaco-action-bar .action-item.select-container{align-items:center;display:flex;flex:1 1;justify-content:center;margin-right:10px;max-width:170px;min-width:60px;overflow:hidden}.monaco-action-bar .action-item.action-dropdown-item{display:flex}.monaco-action-bar .action-item.action-dropdown-item>.action-dropdown-item-separator{align-items:center;cursor:default;display:flex}.monaco-action-bar .action-item.action-dropdown-item>.action-dropdown-item-separator>div{width:1px}.action-widget{background-color:var(--vscode-editorActionList-background);border:1px solid var(--vscode-editorWidget-border)!important;border-radius:0;border-radius:5px;box-shadow:0 2px 8px var(--vscode-widget-shadow);color:var(--vscode-editorActionList-foreground);display:block;font-size:13px;max-width:80vw;min-width:160px;padding:4px;width:100%;z-index:40}.context-view-block{z-index:-1}.context-view-block,.context-view-pointerBlock{cursor:auto;height:100%;left:0;position:fixed;top:0;width:100%}.context-view-pointerBlock{z-index:2}.action-widget .monaco-list{border:0!important;user-select:none;-webkit-user-select:none}.action-widget .monaco-list:focus:before{outline:0!important}.action-widget .monaco-list .monaco-scrollable-element{overflow:visible}.action-widget .monaco-list .monaco-list-row{border-radius:4px;cursor:pointer;padding:0 10px;touch-action:none;white-space:nowrap;width:100%}.action-widget .monaco-list .monaco-list-row.action.focused:not(.option-disabled){background-color:var(--vscode-editorActionList-focusBackground)!important;color:var(--vscode-editorActionList-focusForeground);outline:1px solid var(--vscode-menu-selectionBorder,#0000);outline-offset:-1px}.action-widget .monaco-list-row.group-header{color:var(--vscode-descriptionForeground)!important;font-size:12px;font-weight:600}.action-widget .monaco-list-row.group-header:not(:first-of-type){margin-top:2px}.action-widget .monaco-list .group-header,.action-widget .monaco-list .option-disabled,.action-widget .monaco-list .option-disabled .focused,.action-widget .monaco-list .option-disabled .focused:before,.action-widget .monaco-list .option-disabled:before{-webkit-touch-callout:none;background-color:initial!important;cursor:default!important;outline:0 solid!important;-webkit-user-select:none;user-select:none}.action-widget .monaco-list-row.action{align-items:center;display:flex;gap:8px}.action-widget .monaco-list-row.action.option-disabled,.action-widget .monaco-list-row.action.option-disabled .codicon,.action-widget .monaco-list:focus .monaco-list-row.focused.action.option-disabled,.action-widget .monaco-list:not(.drop-target):not(.dragging) .monaco-list-row:hover:not(.selected):not(.focused).option-disabled{color:var(--vscode-disabledForeground)}.action-widget .monaco-list-row.action:not(.option-disabled) .codicon{color:inherit}.action-widget .monaco-list-row.action .title{flex:1 1;overflow:hidden;text-overflow:ellipsis}.action-widget .monaco-list-row.action .monaco-keybinding>.monaco-keybinding-key{background-color:var(--vscode-keybindingLabel-background);border-color:var(--vscode-keybindingLabel-border);border-bottom-color:var(--vscode-keybindingLabel-bottomBorder);border-radius:3px;border-style:solid;border-width:1px;box-shadow:inset 0 -1px 0 var(--vscode-widget-shadow);color:var(--vscode-keybindingLabel-foreground)}.action-widget .action-widget-action-bar{background-color:var(--vscode-editorActionList-background);border-top:1px solid var(--vscode-editorHoverWidget-border);margin-top:2px}.action-widget .action-widget-action-bar:before{content:"";display:block;width:100%}.action-widget .action-widget-action-bar .actions-container{padding:3px 8px 0}.action-widget-action-bar .action-label{color:var(--vscode-textLink-activeForeground);font-size:12px;line-height:22px;padding:0;pointer-events:all}.action-widget-action-bar .action-item{margin-right:16px;pointer-events:none}.action-widget-action-bar .action-label:hover{background-color:initial!important}.monaco-action-bar .actions-container.highlight-toggled .action-label.checked{background:var(--vscode-actionBar-toggledBackground)!important}.monaco-keybinding{align-items:center;display:flex;line-height:10px}.monaco-keybinding>.monaco-keybinding-key{border-radius:3px;border-style:solid;border-width:1px;display:inline-block;font-size:11px;margin:0 2px;padding:3px 5px;vertical-align:middle}.monaco-keybinding>.monaco-keybinding-key:first-child{margin-left:0}.monaco-keybinding>.monaco-keybinding-key:last-child{margin-right:0}.monaco-keybinding>.monaco-keybinding-key-separator{display:inline-block}.monaco-keybinding>.monaco-keybinding-key-chord-separator{width:6px}::-ms-clear{display:none}.monaco-editor .editor-widget input{color:inherit}.monaco-editor{-webkit-text-size-adjust:100%;color:var(--vscode-editor-foreground);overflow:visible;overflow-wrap:normal;position:relative}.monaco-editor,.monaco-editor-background{background-color:var(--vscode-editor-background)}.monaco-editor .rangeHighlight{background-color:var(--vscode-editor-rangeHighlightBackground);border:1px solid var(--vscode-editor-rangeHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .rangeHighlight,.monaco-editor.hc-light .rangeHighlight{border-style:dotted}.monaco-editor .symbolHighlight{background-color:var(--vscode-editor-symbolHighlightBackground);border:1px solid var(--vscode-editor-symbolHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .symbolHighlight,.monaco-editor.hc-light .symbolHighlight{border-style:dotted}.monaco-editor .overflow-guard{overflow:hidden;position:relative}.monaco-editor .view-overlays{position:absolute;top:0}.monaco-editor .margin-view-overlays>div,.monaco-editor .view-overlays>div{position:absolute;width:100%}.monaco-editor .squiggly-error{border-bottom:4px double var(--vscode-editorError-border)}.monaco-editor .squiggly-error:before{background:var(--vscode-editorError-background);content:"";display:block;height:100%;width:100%}.monaco-editor .squiggly-warning{border-bottom:4px double var(--vscode-editorWarning-border)}.monaco-editor .squiggly-warning:before{background:var(--vscode-editorWarning-background);content:"";display:block;height:100%;width:100%}.monaco-editor .squiggly-info{border-bottom:4px double var(--vscode-editorInfo-border)}.monaco-editor .squiggly-info:before{background:var(--vscode-editorInfo-background);content:"";display:block;height:100%;width:100%}.monaco-editor .squiggly-hint{border-bottom:2px dotted var(--vscode-editorHint-border)}.monaco-editor.showUnused .squiggly-unnecessary{border-bottom:2px dashed var(--vscode-editorUnnecessaryCode-border)}.monaco-editor.showDeprecated .squiggly-inline-deprecated{text-decoration:line-through;text-decoration-color:var(--vscode-editor-foreground,inherit)}.monaco-editor .inputarea{background-color:initial;border:none;color:#0000;margin:0;min-height:0;min-width:0;outline:none!important;overflow:hidden;padding:0;position:absolute;resize:none;z-index:-10}.monaco-editor .inputarea.ime-input{caret-color:var(--vscode-editorCursor-foreground);color:var(--vscode-editor-foreground);z-index:10}.monaco-editor .margin-view-overlays .line-numbers{font-feature-settings:"tnum";bottom:0;box-sizing:border-box;cursor:default;display:inline-block;font-variant-numeric:tabular-nums;position:absolute;text-align:right;vertical-align:middle}.monaco-editor .relative-current-line-number{display:inline-block;text-align:left;width:100%}.monaco-editor .margin-view-overlays .line-numbers.lh-odd{margin-top:1px}.monaco-editor .line-numbers{color:var(--vscode-editorLineNumber-foreground)}.monaco-editor .line-numbers.active-line-number{color:var(--vscode-editorLineNumber-activeForeground)}.monaco-editor .margin{background-color:var(--vscode-editorGutter-background)}.monaco-mouse-cursor-text{cursor:text}.monaco-editor .blockDecorations-container{pointer-events:none;position:absolute;top:0}.monaco-editor .blockDecorations-block{box-sizing:border-box;position:absolute}.monaco-editor .margin-view-overlays .current-line,.monaco-editor .view-overlays .current-line{box-sizing:border-box;display:block;height:100%;left:0;position:absolute;top:0}.monaco-editor - .margin-view-overlays - .current-line.current-line-margin.current-line-margin-both{border-right:0}.monaco-editor .lines-content .cdr{height:100%;position:absolute}.monaco-editor .glyph-margin{position:absolute;top:0}.monaco-editor .glyph-margin-widgets .cgmr{align-items:center;display:flex;justify-content:center;position:absolute}.monaco-editor .glyph-margin-widgets .cgmr.codicon-modifier-spin:before{left:50%;position:absolute;top:50%;transform:translate(-50%,-50%)}.monaco-editor .lines-content .core-guide{box-sizing:border-box;height:100%;position:absolute}.mtkcontrol{background:#960000!important;color:#fff!important}.mtkoverflow{background-color:var(--vscode-button-background,var(--vscode-editor-background));border-color:var(--vscode-contrastBorder);border-radius:2px;border-style:solid;border-width:1px;color:var(--vscode-button-foreground,var(--vscode-editor-foreground));cursor:pointer;padding:4px}.mtkoverflow:hover{background-color:var(--vscode-button-hoverBackground)}.monaco-editor.no-user-select .lines-content,.monaco-editor.no-user-select .view-line,.monaco-editor.no-user-select .view-lines{user-select:none;-webkit-user-select:none}.monaco-editor.mac .lines-content:hover,.monaco-editor.mac .view-line:hover,.monaco-editor.mac .view-lines:hover{user-select:text;-webkit-user-select:text;-ms-user-select:text}.monaco-editor.enable-user-select{user-select:auto;-webkit-user-select:initial}.monaco-editor .view-lines{white-space:nowrap}.monaco-editor .view-line{position:absolute;width:100%}.monaco-editor .lines-content>.view-lines>.view-line>span{bottom:0;position:absolute;top:0}.monaco-editor .mtkw,.monaco-editor .mtkz{color:var(--vscode-editorWhitespace-foreground)!important}.monaco-editor .mtkz{display:inline-block}.monaco-editor .lines-decorations{background:#fff;position:absolute;top:0}.monaco-editor .margin-view-overlays .cldr{height:100%;position:absolute}.monaco-editor .margin-view-overlays .cmdr{height:100%;left:0;position:absolute;width:100%}.monaco-editor .minimap.slider-mouseover .minimap-slider{opacity:0;transition:opacity .1s linear}.monaco-editor .minimap.slider-mouseover .minimap-slider.active,.monaco-editor .minimap.slider-mouseover:hover .minimap-slider{opacity:1}.monaco-editor .minimap-slider .minimap-slider-horizontal{background:var(--vscode-minimapSlider-background)}.monaco-editor .minimap-slider:hover .minimap-slider-horizontal{background:var(--vscode-minimapSlider-hoverBackground)}.monaco-editor .minimap-slider.active .minimap-slider-horizontal{background:var(--vscode-minimapSlider-activeBackground)}.monaco-editor .minimap-shadow-visible{box-shadow:var(--vscode-scrollbar-shadow) -6px 0 6px -6px inset}.monaco-editor .minimap-shadow-hidden{position:absolute;width:0}.monaco-editor .minimap-shadow-visible{left:-6px;position:absolute;width:6px}.monaco-editor.no-minimap-shadow .minimap-shadow-visible{left:-1px;position:absolute;width:1px}.minimap.autohide{opacity:0;transition:opacity .5s}.minimap.autohide:hover{opacity:1}.monaco-editor .minimap{z-index:5}.monaco-editor .overlayWidgets{left:0;position:absolute;top:0}.monaco-editor .view-ruler{box-shadow:1px 0 0 0 var(--vscode-editorRuler-foreground) inset;position:absolute;top:0}.monaco-editor .scroll-decoration{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px inset;height:6px;left:0;position:absolute;top:0}.monaco-editor .lines-content .cslr{position:absolute}.monaco-editor .focused .selected-text{background-color:var(--vscode-editor-selectionBackground)}.monaco-editor .selected-text{background-color:var(--vscode-editor-inactiveSelectionBackground)}.monaco-editor .top-left-radius{border-top-left-radius:3px}.monaco-editor .bottom-left-radius{border-bottom-left-radius:3px}.monaco-editor .top-right-radius{border-top-right-radius:3px}.monaco-editor .bottom-right-radius{border-bottom-right-radius:3px}.monaco-editor.hc-black .top-left-radius{border-top-left-radius:0}.monaco-editor.hc-black .bottom-left-radius{border-bottom-left-radius:0}.monaco-editor.hc-black .top-right-radius{border-top-right-radius:0}.monaco-editor.hc-black .bottom-right-radius{border-bottom-right-radius:0}.monaco-editor.hc-light .top-left-radius{border-top-left-radius:0}.monaco-editor.hc-light .bottom-left-radius{border-bottom-left-radius:0}.monaco-editor.hc-light .top-right-radius{border-top-right-radius:0}.monaco-editor.hc-light .bottom-right-radius{border-bottom-right-radius:0}.monaco-editor .cursors-layer{position:absolute;top:0}.monaco-editor .cursors-layer>.cursor{box-sizing:border-box;overflow:hidden;position:absolute}.monaco-editor .cursors-layer.cursor-smooth-caret-animation>.cursor{transition:all 80ms}.monaco-editor .cursors-layer.cursor-block-outline-style>.cursor{background:#0000!important;border-style:solid;border-width:1px}.monaco-editor .cursors-layer.cursor-underline-style>.cursor{background:#0000!important;border-bottom-style:solid;border-bottom-width:2px}.monaco-editor .cursors-layer.cursor-underline-thin-style>.cursor{background:#0000!important;border-bottom-style:solid;border-bottom-width:1px}@keyframes monaco-cursor-smooth{0%,20%{opacity:1}60%,to{opacity:0}}@keyframes monaco-cursor-phase{0%,20%{opacity:1}90%,to{opacity:0}}@keyframes monaco-cursor-expand{0%,20%{transform:scaleY(1)}80%,to{transform:scaleY(0)}}.cursor-smooth{animation:monaco-cursor-smooth .5s ease-in-out 0s 20 alternate}.cursor-phase{animation:monaco-cursor-phase .5s ease-in-out 0s 20 alternate}.cursor-expand>.cursor{animation:monaco-cursor-expand .5s ease-in-out 0s 20 alternate}.monaco-editor .mwh{color:var(--vscode-editorWhitespace-foreground)!important;position:absolute}.monaco-editor .codelens-decoration{font-feature-settings:var(--vscode-editorCodeLens-fontFeatureSettings);color:var(--vscode-editorCodeLens-foreground);display:inline-block;font-family:var(--vscode-editorCodeLens-fontFamily),var(--vscode-editorCodeLens-fontFamilyDefault);font-size:var(--vscode-editorCodeLens-fontSize);line-height:var(--vscode-editorCodeLens-lineHeight);overflow:hidden;padding-right:calc(var(--vscode-editorCodeLens-fontSize)*.5);text-overflow:ellipsis;white-space:nowrap}.monaco-editor .codelens-decoration>a,.monaco-editor .codelens-decoration>span{user-select:none;-webkit-user-select:none;vertical-align:sub;white-space:nowrap}.monaco-editor .codelens-decoration>a{text-decoration:none}.monaco-editor .codelens-decoration>a:hover{cursor:pointer}.monaco-editor .codelens-decoration>a:hover,.monaco-editor .codelens-decoration>a:hover .codicon{color:var(--vscode-editorLink-activeForeground)!important}.monaco-editor .codelens-decoration .codicon{color:currentColor!important;color:var(--vscode-editorCodeLens-foreground);font-size:var(--vscode-editorCodeLens-fontSize);line-height:var(--vscode-editorCodeLens-lineHeight);vertical-align:middle}.monaco-editor .codelens-decoration>a:hover .codicon:before{cursor:pointer}@keyframes fadein{0%{opacity:0;visibility:visible}to{opacity:1}}.monaco-editor .codelens-decoration.fadein{animation:fadein .1s linear}.colorpicker-widget{height:190px;user-select:none;-webkit-user-select:none}.colorpicker-color-decoration,.hc-light .colorpicker-color-decoration{border:.1em solid #000;box-sizing:border-box;cursor:pointer;display:inline-block;height:.8em;line-height:.8em;margin:.1em .2em 0;width:.8em}.hc-black .colorpicker-color-decoration,.vs-dark .colorpicker-color-decoration{border:.1em solid #eee}.colorpicker-header{background:url(data:image/png;base64,iVBORw0KGgoAAAANSUhEUgAAAAQAAAAECAYAAACp8Z5+AAAAAXNSR0IArs4c6QAAAARnQU1BAACxjwv8YQUAAAAJcEhZcwAADsMAAA7DAcdvqGQAAAAZdEVYdFNvZnR3YXJlAHBhaW50Lm5ldCA0LjAuMTZEaa/1AAAAHUlEQVQYV2PYvXu3JAi7uLiAMaYAjAGTQBPYLQkAa/0Zef3qRswAAAAASUVORK5CYII=);background-size:9px 9px;display:flex;height:24px;image-rendering:pixelated;position:relative}.colorpicker-header .picked-color{align-items:center;color:#fff;cursor:pointer;display:flex;flex:1 1;justify-content:center;line-height:24px;overflow:hidden;white-space:nowrap;width:240px}.colorpicker-header .picked-color .picked-color-presentation{margin-left:5px;margin-right:5px;white-space:nowrap}.colorpicker-header .picked-color .codicon{color:inherit;font-size:14px}.colorpicker-header .picked-color.light{color:#000}.colorpicker-header .original-color{cursor:pointer;width:74px;z-index:inherit}.standalone-colorpicker{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground)}.colorpicker-header.standalone-colorpicker{border-bottom:none}.colorpicker-header .close-button{background-color:var(--vscode-editorHoverWidget-background);border-left:1px solid var(--vscode-editorHoverWidget-border);cursor:pointer}.colorpicker-header .close-button-inner-div{height:100%;text-align:center;width:100%}.colorpicker-header .close-button-inner-div:hover{background-color:var(--vscode-toolbar-hoverBackground)}.colorpicker-header .close-icon{padding:3px}.colorpicker-body{display:flex;padding:8px;position:relative}.colorpicker-body .saturation-wrap{flex:1 1;height:150px;min-width:220px;overflow:hidden;position:relative}.colorpicker-body .saturation-box{height:150px;position:absolute}.colorpicker-body .saturation-selection{border:1px solid #fff;border-radius:100%;box-shadow:0 0 2px #000c;height:9px;margin:-5px 0 0 -5px;position:absolute;width:9px}.colorpicker-body .strip{height:150px;width:25px}.colorpicker-body .standalone-strip{height:122px;width:25px}.colorpicker-body .hue-strip{background:linear-gradient(180deg,red 0,#ff0 17%,#0f0 33%,#0ff 50%,#00f 67%,#f0f 83%,red);cursor:grab;margin-left:8px;position:relative}.colorpicker-body .opacity-strip{background:url(data:image/png;base64,iVBORw0KGgoAAAANSUhEUgAAAAQAAAAECAYAAACp8Z5+AAAAAXNSR0IArs4c6QAAAARnQU1BAACxjwv8YQUAAAAJcEhZcwAADsMAAA7DAcdvqGQAAAAZdEVYdFNvZnR3YXJlAHBhaW50Lm5ldCA0LjAuMTZEaa/1AAAAHUlEQVQYV2PYvXu3JAi7uLiAMaYAjAGTQBPYLQkAa/0Zef3qRswAAAAASUVORK5CYII=);background-size:9px 9px;cursor:grab;image-rendering:pixelated;margin-left:8px;position:relative}.colorpicker-body .strip.grabbing{cursor:grabbing}.colorpicker-body .slider{border:1px solid #ffffffb5;box-shadow:0 0 1px #000000d9;box-sizing:border-box;height:4px;left:-2px;position:absolute;top:0;width:calc(100% + 4px)}.colorpicker-body .strip .overlay{height:150px;pointer-events:none}.colorpicker-body .standalone-strip .standalone-overlay{height:122px;pointer-events:none}.standalone-colorpicker-body{border:1px solid #0000;border-bottom:1px solid var(--vscode-editorHoverWidget-border);display:block;overflow:hidden}.colorpicker-body .insert-button{background:var(--vscode-button-background);border:none;border-radius:2px;bottom:8px;color:var(--vscode-button-foreground);cursor:pointer;height:20px;padding:0;position:absolute;right:8px;width:58px}.colorpicker-body .insert-button:hover{background:var(--vscode-button-hoverBackground)}.monaco-editor .inlineSuggestionsHints.withBorder{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);z-index:39}.monaco-editor .inlineSuggestionsHints a,.monaco-editor .inlineSuggestionsHints a:hover{color:var(--vscode-foreground)}.monaco-editor .inlineSuggestionsHints .keybinding{display:flex;margin-left:4px;opacity:.6}.monaco-editor .inlineSuggestionsHints .keybinding .monaco-keybinding-key{font-size:8px;padding:2px 3px}.monaco-editor .inlineSuggestionsHints .availableSuggestionCount a{display:flex;justify-content:center;min-width:19px}.monaco-editor .inlineSuggestionStatusBarItemLabel{margin-right:2px}.monaco-dropdown{height:100%;padding:0}.monaco-dropdown>.dropdown-label{align-items:center;cursor:pointer;display:flex;height:100%;justify-content:center}.monaco-dropdown>.dropdown-label>.action-label.disabled{cursor:default}.monaco-dropdown-with-primary{border-radius:5px;display:flex!important;flex-direction:row}.monaco-dropdown-with-primary>.action-container>.action-label{margin-right:0}.monaco-dropdown-with-primary>.dropdown-action-container>.monaco-dropdown>.dropdown-label .codicon[class*=codicon-]{font-size:12px;line-height:16px;margin-left:-3px;padding-left:0;padding-right:0}.monaco-dropdown-with-primary>.dropdown-action-container>.monaco-dropdown>.dropdown-label>.action-label{background-position:50%;background-repeat:no-repeat;background-size:16px;display:block}.monaco-action-bar .action-item.menu-entry .action-label.icon{background-position:50%;background-repeat:no-repeat;background-size:16px;height:16px;width:16px}.monaco-action-bar .action-item.menu-entry.text-only .action-label{border-radius:2px;color:var(--vscode-descriptionForeground);overflow:hidden}.monaco-action-bar .action-item.menu-entry.text-only.use-comma:not(:last-of-type) .action-label:after{content:", "}.monaco-action-bar .action-item.menu-entry.text-only+.action-item:not(.text-only)>.monaco-dropdown .action-label{color:var(--vscode-descriptionForeground)}.monaco-dropdown-with-default{border-radius:5px;display:flex!important;flex-direction:row}.monaco-dropdown-with-default>.action-container>.action-label{margin-right:0}.monaco-dropdown-with-default>.action-container.menu-entry>.action-label.icon{background-position:50%;background-repeat:no-repeat;background-size:16px;height:16px;width:16px}.monaco-dropdown-with-default:hover{background-color:var(--vscode-toolbar-hoverBackground)}.monaco-dropdown-with-default>.dropdown-action-container>.monaco-dropdown>.dropdown-label .codicon[class*=codicon-]{font-size:12px;line-height:16px;margin-left:-3px;padding-left:0;padding-right:0}.monaco-dropdown-with-default>.dropdown-action-container>.monaco-dropdown>.dropdown-label>.action-label{background-position:50%;background-repeat:no-repeat;background-size:16px;display:block}.monaco-toolbar{height:100%}.monaco-toolbar .toolbar-toggle-more{display:inline-block;padding:0}:root{--vscode-sash-size:4px;--vscode-sash-hover-size:4px}.monaco-sash{position:absolute;touch-action:none;z-index:35}.monaco-sash.disabled{pointer-events:none}.monaco-sash.mac.vertical{cursor:col-resize}.monaco-sash.vertical.minimum{cursor:e-resize}.monaco-sash.vertical.maximum{cursor:w-resize}.monaco-sash.mac.horizontal{cursor:row-resize}.monaco-sash.horizontal.minimum{cursor:s-resize}.monaco-sash.horizontal.maximum{cursor:n-resize}.monaco-sash.disabled{cursor:default!important;pointer-events:none!important}.monaco-sash.vertical{cursor:ew-resize;height:100%;top:0;width:var(--vscode-sash-size)}.monaco-sash.horizontal{cursor:ns-resize;height:var(--vscode-sash-size);left:0;width:100%}.monaco-sash:not(.disabled)>.orthogonal-drag-handle{content:" ";cursor:all-scroll;display:block;height:calc(var(--vscode-sash-size)*2);position:absolute;width:calc(var(--vscode-sash-size)*2);z-index:100}.monaco-sash.horizontal.orthogonal-edge-north:not(.disabled)>.orthogonal-drag-handle.start,.monaco-sash.horizontal.orthogonal-edge-south:not(.disabled)>.orthogonal-drag-handle.end{cursor:nwse-resize}.monaco-sash.horizontal.orthogonal-edge-north:not(.disabled)>.orthogonal-drag-handle.end,.monaco-sash.horizontal.orthogonal-edge-south:not(.disabled)>.orthogonal-drag-handle.start{cursor:nesw-resize}.monaco-sash.vertical>.orthogonal-drag-handle.start{left:calc(var(--vscode-sash-size)*-.5);top:calc(var(--vscode-sash-size)*-1)}.monaco-sash.vertical>.orthogonal-drag-handle.end{bottom:calc(var(--vscode-sash-size)*-1);left:calc(var(--vscode-sash-size)*-.5)}.monaco-sash.horizontal>.orthogonal-drag-handle.start{left:calc(var(--vscode-sash-size)*-1);top:calc(var(--vscode-sash-size)*-.5)}.monaco-sash.horizontal>.orthogonal-drag-handle.end{right:calc(var(--vscode-sash-size)*-1);top:calc(var(--vscode-sash-size)*-.5)}.monaco-sash:before{background:#0000;content:"";height:100%;pointer-events:none;position:absolute;width:100%}.monaco-workbench:not(.reduce-motion) .monaco-sash:before{transition:background-color .1s ease-out}.monaco-sash.active:before,.monaco-sash.hover:before{background:var(--vscode-sash-hoverBorder)}.monaco-sash.vertical:before{left:calc(50% - var(--vscode-sash-hover-size)/2);width:var(--vscode-sash-hover-size)}.monaco-sash.horizontal:before{height:var(--vscode-sash-hover-size);top:calc(50% - var(--vscode-sash-hover-size)/2)}.pointer-events-disabled{pointer-events:none!important}.monaco-sash.debug{background:cyan}.monaco-sash.debug.disabled{background:#0ff3}.monaco-sash.debug:not(.disabled)>.orthogonal-drag-handle{background:red}.monaco-hover{animation:fadein .1s linear;box-sizing:border-box;cursor:default;line-height:1.5em;overflow:hidden;position:absolute;user-select:text;-webkit-user-select:text;white-space:var(--vscode-hover-whiteSpace,normal)}.monaco-hover.hidden{display:none}.monaco-hover a:hover:not(.disabled){cursor:pointer}.monaco-hover .hover-contents:not(.html-hover-contents){padding:4px 8px}.monaco-hover .markdown-hover>.hover-contents:not(.code-hover-contents){word-wrap:break-word;max-width:var(--vscode-hover-maxWidth,500px)}.monaco-hover .markdown-hover>.hover-contents:not(.code-hover-contents) hr{min-width:100%}.monaco-hover .code,.monaco-hover h1,.monaco-hover h2,.monaco-hover h3,.monaco-hover h4,.monaco-hover h5,.monaco-hover h6,.monaco-hover p,.monaco-hover ul{margin:8px 0}.monaco-hover h1,.monaco-hover h2,.monaco-hover h3,.monaco-hover h4,.monaco-hover h5,.monaco-hover h6{line-height:1.1}.monaco-hover code{font-family:var(--monaco-monospace-font)}.monaco-hover hr{border-left:0;border-right:0;box-sizing:border-box;height:1px;margin:4px -8px -4px}.monaco-hover .code:first-child,.monaco-hover p:first-child,.monaco-hover ul:first-child{margin-top:0}.monaco-hover .code:last-child,.monaco-hover p:last-child,.monaco-hover ul:last-child{margin-bottom:0}.monaco-hover ol,.monaco-hover ul{padding-left:20px}.monaco-hover li>p{margin-bottom:0}.monaco-hover li>ul{margin-top:0}.monaco-hover code{border-radius:3px;padding:0 .4em}.monaco-hover .monaco-tokenized-source{white-space:var(--vscode-hover-sourceWhiteSpace,pre-wrap)}.monaco-hover .hover-row.status-bar{font-size:12px;line-height:22px}.monaco-hover .hover-row.status-bar .info{font-style:italic;padding:0 8px}.monaco-hover .hover-row.status-bar .actions{display:flex;padding:0 8px;width:100%}.monaco-hover .hover-row.status-bar .actions .action-container{cursor:pointer;margin-right:16px}.monaco-hover .hover-row.status-bar .actions .action-container .action .icon{padding-right:4px}.monaco-hover .hover-row.status-bar .actions .action-container a{color:var(--vscode-textLink-foreground);-webkit-text-decoration:var(--text-link-decoration);text-decoration:var(--text-link-decoration)}.monaco-hover .markdown-hover .hover-contents .codicon{color:inherit;font-size:inherit;vertical-align:middle}.monaco-hover .hover-contents a.code-link,.monaco-hover .hover-contents a.code-link:hover{color:inherit}.monaco-hover .hover-contents a.code-link:before{content:"("}.monaco-hover .hover-contents a.code-link:after{content:")"}.monaco-hover .hover-contents a.code-link>span{border-bottom:1px solid #0000;color:var(--vscode-textLink-foreground);text-decoration:underline;text-underline-position:under}.monaco-hover .hover-contents a.code-link>span:hover{color:var(--vscode-textLink-activeForeground)}.monaco-hover .markdown-hover .hover-contents:not(.code-hover-contents):not(.html-hover-contents) span{display:inline-block;margin-bottom:4px}.monaco-hover .markdown-hover .hover-contents:not(.code-hover-contents):not(.html-hover-contents) span.codicon{margin-bottom:2px}.monaco-hover-content .action-container a{-webkit-user-select:none;user-select:none}.monaco-hover-content .action-container.disabled{cursor:default;opacity:.4;pointer-events:none}.monaco-editor .peekview-widget .head{box-sizing:border-box;display:flex;flex-wrap:nowrap;justify-content:space-between}.monaco-editor .peekview-widget .head .peekview-title{align-items:baseline;display:flex;font-size:13px;margin-left:20px;min-width:0;overflow:hidden;text-overflow:ellipsis}.monaco-editor .peekview-widget .head .peekview-title.clickable{cursor:pointer}.monaco-editor .peekview-widget .head .peekview-title .dirname:not(:empty){font-size:.9em;margin-left:.5em}.monaco-editor .peekview-widget .head .peekview-title .dirname,.monaco-editor .peekview-widget .head .peekview-title .filename,.monaco-editor .peekview-widget .head .peekview-title .meta{overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-editor .peekview-widget .head .peekview-title .meta:not(:empty):before{content:"-";padding:0 .3em}.monaco-editor .peekview-widget .head .peekview-actions{flex:1 1;padding-right:2px;text-align:right}.monaco-editor .peekview-widget .head .peekview-actions>.monaco-action-bar{display:inline-block}.monaco-editor .peekview-widget .head .peekview-actions>.monaco-action-bar,.monaco-editor .peekview-widget .head .peekview-actions>.monaco-action-bar>.actions-container{height:100%}.monaco-editor .peekview-widget>.body{border-top:1px solid;position:relative}.monaco-editor .peekview-widget .head .peekview-title .codicon{align-self:center;margin-right:4px}.monaco-editor .peekview-widget .monaco-list .monaco-list-row.focused .codicon{color:inherit!important}.monaco-editor .zone-widget{position:absolute;z-index:10}.monaco-editor .zone-widget .zone-widget-container{border-bottom-style:solid;border-bottom-width:0;border-top-style:solid;border-top-width:0;position:relative}.monaco-split-view2{height:100%;position:relative;width:100%}.monaco-split-view2>.sash-container{height:100%;pointer-events:none;position:absolute;width:100%}.monaco-split-view2>.sash-container>.monaco-sash{pointer-events:auto}.monaco-split-view2>.monaco-scrollable-element{height:100%;width:100%}.monaco-split-view2>.monaco-scrollable-element>.split-view-container{height:100%;position:relative;white-space:nowrap;width:100%}.monaco-split-view2>.monaco-scrollable-element>.split-view-container>.split-view-view{position:absolute;white-space:normal}.monaco-split-view2>.monaco-scrollable-element>.split-view-container>.split-view-view:not(.visible){display:none}.monaco-split-view2.vertical>.monaco-scrollable-element>.split-view-container>.split-view-view{width:100%}.monaco-split-view2.horizontal>.monaco-scrollable-element>.split-view-container>.split-view-view{height:100%}.monaco-split-view2.separator-border>.monaco-scrollable-element>.split-view-container>.split-view-view:not(:first-child):before{background-color:var(--separator-border);content:" ";left:0;pointer-events:none;position:absolute;top:0;z-index:5}.monaco-split-view2.separator-border.horizontal>.monaco-scrollable-element>.split-view-container>.split-view-view:not(:first-child):before{height:100%;width:1px}.monaco-split-view2.separator-border.vertical>.monaco-scrollable-element>.split-view-container>.split-view-view:not(:first-child):before{height:1px;width:100%}.monaco-table{display:flex;flex-direction:column;height:100%;overflow:hidden;position:relative;white-space:nowrap;width:100%}.monaco-table>.monaco-split-view2{border-bottom:1px solid #0000}.monaco-table>.monaco-list{flex:1 1}.monaco-table-tr{display:flex;height:100%}.monaco-table-th{font-weight:700;height:100%;overflow:hidden;text-overflow:ellipsis;width:100%}.monaco-table-td,.monaco-table-th{box-sizing:border-box;flex-shrink:0;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-table>.monaco-split-view2 .monaco-sash.vertical:before{border-left:1px solid #0000;content:"";left:calc(var(--vscode-sash-size)/2);position:absolute;width:0}.monaco-workbench:not(.reduce-motion) .monaco-table>.monaco-split-view2,.monaco-workbench:not(.reduce-motion) .monaco-table>.monaco-split-view2 .monaco-sash.vertical:before{transition:border-color .2s ease-out}.monaco-custom-toggle{border:1px solid #0000;border-radius:3px;box-sizing:border-box;cursor:pointer;float:left;height:20px;margin-left:2px;overflow:hidden;padding:1px;user-select:none;-webkit-user-select:none;width:20px}.monaco-custom-toggle:hover{background-color:var(--vscode-inputOption-hoverBackground)}.hc-black .monaco-custom-toggle:hover,.hc-light .monaco-custom-toggle:hover{border:1px dashed var(--vscode-focusBorder)}.hc-black .monaco-custom-toggle,.hc-black .monaco-custom-toggle:hover,.hc-light .monaco-custom-toggle,.hc-light .monaco-custom-toggle:hover{background:none}.monaco-custom-toggle.monaco-checkbox{background-size:16px!important;border:1px solid #0000;border-radius:3px;height:18px;margin-left:0;margin-right:9px;opacity:1;padding:0;width:18px}.monaco-action-bar .checkbox-action-item{align-items:center;border-radius:2px;display:flex;padding-right:2px}.monaco-action-bar .checkbox-action-item:hover{background-color:var(--vscode-toolbar-hoverBackground)}.monaco-action-bar .checkbox-action-item>.monaco-custom-toggle.monaco-checkbox{margin-right:4px}.monaco-action-bar .checkbox-action-item>.checkbox-label{font-size:12px}.monaco-custom-toggle.monaco-checkbox:not(.checked):before{visibility:hidden}.monaco-inputbox{border-radius:2px;box-sizing:border-box;display:block;font-size:inherit;padding:0;position:relative}.monaco-inputbox>.ibwrapper>.input,.monaco-inputbox>.ibwrapper>.mirror{padding:4px 6px}.monaco-inputbox>.ibwrapper{height:100%;position:relative;width:100%}.monaco-inputbox>.ibwrapper>.input{border:none;box-sizing:border-box;color:inherit;display:inline-block;font-family:inherit;font-size:inherit;height:100%;line-height:inherit;resize:none;width:100%}.monaco-inputbox>.ibwrapper>input{text-overflow:ellipsis}.monaco-inputbox>.ibwrapper>textarea.input{display:block;outline:none;scrollbar-width:none}.monaco-inputbox>.ibwrapper>textarea.input::-webkit-scrollbar{display:none}.monaco-inputbox>.ibwrapper>textarea.input.empty{white-space:nowrap}.monaco-inputbox>.ibwrapper>.mirror{word-wrap:break-word;box-sizing:border-box;display:inline-block;left:0;position:absolute;top:0;visibility:hidden;white-space:pre-wrap;width:100%}.monaco-inputbox-container{text-align:right}.monaco-inputbox-container .monaco-inputbox-message{word-wrap:break-word;box-sizing:border-box;display:inline-block;font-size:12px;line-height:17px;margin-top:-1px;overflow:hidden;padding:.4em;text-align:left;width:100%}.monaco-inputbox .monaco-action-bar{position:absolute;right:2px;top:4px}.monaco-inputbox .monaco-action-bar .action-item{margin-left:2px}.monaco-inputbox .monaco-action-bar .action-item .codicon{background-repeat:no-repeat;height:16px;width:16px}.monaco-findInput{position:relative}.monaco-findInput .monaco-inputbox{font-size:13px;width:100%}.monaco-findInput>.controls{position:absolute;right:2px;top:3px}.vs .monaco-findInput.disabled{background-color:#e1e1e1}.vs-dark .monaco-findInput.disabled{background-color:#333}.hc-light .monaco-findInput.highlight-0 .controls,.monaco-findInput.highlight-0 .controls{animation:monaco-findInput-highlight-0 .1s linear 0s}.hc-light .monaco-findInput.highlight-1 .controls,.monaco-findInput.highlight-1 .controls{animation:monaco-findInput-highlight-1 .1s linear 0s}.hc-black .monaco-findInput.highlight-0 .controls,.vs-dark .monaco-findInput.highlight-0 .controls{animation:monaco-findInput-highlight-dark-0 .1s linear 0s}.hc-black .monaco-findInput.highlight-1 .controls,.vs-dark .monaco-findInput.highlight-1 .controls{animation:monaco-findInput-highlight-dark-1 .1s linear 0s}@keyframes monaco-findInput-highlight-0{0%{background:#fdff00cc}to{background:#0000}}@keyframes monaco-findInput-highlight-1{0%{background:#fdff00cc}99%{background:#0000}}@keyframes monaco-findInput-highlight-dark-0{0%{background:#ffffff70}to{background:#0000}}@keyframes monaco-findInput-highlight-dark-1{0%{background:#ffffff70}99%{background:#0000}}.monaco-tl-row{align-items:center;display:flex;height:100%;position:relative}.monaco-tl-row.disabled{cursor:default}.monaco-tl-indent{height:100%;left:16px;pointer-events:none;position:absolute;top:0}.hide-arrows .monaco-tl-indent{left:12px}.monaco-tl-indent>.indent-guide{border-left:1px solid #0000;box-sizing:border-box;display:inline-block;height:100%}.monaco-workbench:not(.reduce-motion) .monaco-tl-indent>.indent-guide{transition:border-color .1s linear}.monaco-tl-contents,.monaco-tl-twistie{height:100%}.monaco-tl-twistie{align-items:center;display:flex!important;flex-shrink:0;font-size:10px;justify-content:center;padding-right:6px;text-align:right;transform:translateX(3px);width:16px}.monaco-tl-contents{flex:1 1;overflow:hidden}.monaco-tl-twistie:before{border-radius:20px}.monaco-tl-twistie.collapsed:before{transform:rotate(-90deg)}.monaco-tl-twistie.codicon-tree-item-loading:before{animation:codicon-spin 1.25s steps(30) infinite}.monaco-tree-type-filter{border:1px solid var(--vscode-widget-border);border-bottom-left-radius:4px;border-bottom-right-radius:4px;display:flex;margin:0 6px;max-width:200px;padding:3px;position:absolute;top:0;z-index:100}.monaco-workbench:not(.reduce-motion) .monaco-tree-type-filter{transition:top .3s}.monaco-tree-type-filter.disabled{top:-40px!important}.monaco-tree-type-filter-grab{align-items:center;cursor:grab;display:flex!important;justify-content:center;margin-right:2px}.monaco-tree-type-filter-grab.grabbing{cursor:grabbing}.monaco-tree-type-filter-input{flex:1 1}.monaco-tree-type-filter-input .monaco-inputbox{height:23px}.monaco-tree-type-filter-input .monaco-inputbox>.ibwrapper>.input,.monaco-tree-type-filter-input .monaco-inputbox>.ibwrapper>.mirror{padding:2px 4px}.monaco-tree-type-filter-input .monaco-findInput>.controls{top:2px}.monaco-tree-type-filter-actionbar{margin-left:4px}.monaco-tree-type-filter-actionbar .monaco-action-bar .action-label{padding:2px}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container{background-color:var(--vscode-sideBar-background);height:0;left:0;position:absolute;top:0;width:100%;z-index:13}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-row.monaco-list-row{background-color:var(--vscode-sideBar-background);opacity:1!important;overflow:hidden;position:absolute;width:100%}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-row:hover{background-color:var(--vscode-list-hoverBackground)!important;cursor:pointer}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container.empty,.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container.empty .monaco-tree-sticky-container-shadow{display:none}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-container-shadow{bottom:-3px;height:0;left:0;position:absolute;width:100%}.monaco-list .monaco-scrollable-element .monaco-tree-sticky-container[tabindex="0"]:focus{outline:none}.monaco-editor .zone-widget .zone-widget-container.reference-zone-widget{border-bottom-width:1px;border-top-width:1px}.monaco-editor .reference-zone-widget .inline{display:inline-block;vertical-align:top}.monaco-editor .reference-zone-widget .messages{height:100%;padding:3em 0;text-align:center;width:100%}.monaco-editor .reference-zone-widget .ref-tree{background-color:var(--vscode-peekViewResult-background);color:var(--vscode-peekViewResult-lineForeground);line-height:23px}.monaco-editor .reference-zone-widget .ref-tree .reference{overflow:hidden;text-overflow:ellipsis}.monaco-editor .reference-zone-widget .ref-tree .reference-file{color:var(--vscode-peekViewResult-fileForeground);display:inline-flex;height:100%;width:100%}.monaco-editor .reference-zone-widget .ref-tree .monaco-list:focus .selected .reference-file{color:inherit!important}.monaco-editor .reference-zone-widget .ref-tree .monaco-list:focus .monaco-list-rows>.monaco-list-row.selected:not(.highlighted){background-color:var(--vscode-peekViewResult-selectionBackground);color:var(--vscode-peekViewResult-selectionForeground)!important}.monaco-editor .reference-zone-widget .ref-tree .reference-file .count{margin-left:auto;margin-right:12px}.monaco-editor .reference-zone-widget .ref-tree .referenceMatch .highlight{background-color:var(--vscode-peekViewResult-matchHighlightBackground)}.monaco-editor .reference-zone-widget .preview .reference-decoration{background-color:var(--vscode-peekViewEditor-matchHighlightBackground);border:2px solid var(--vscode-peekViewEditor-matchHighlightBorder);box-sizing:border-box}.monaco-editor .reference-zone-widget .preview .monaco-editor .inputarea.ime-input,.monaco-editor .reference-zone-widget .preview .monaco-editor .monaco-editor-background{background-color:var(--vscode-peekViewEditor-background)}.monaco-editor .reference-zone-widget .preview .monaco-editor .margin{background-color:var(--vscode-peekViewEditorGutter-background)}.monaco-editor.hc-black .reference-zone-widget .ref-tree .reference-file,.monaco-editor.hc-light .reference-zone-widget .ref-tree .reference-file{font-weight:700}.monaco-editor.hc-black .reference-zone-widget .ref-tree .referenceMatch .highlight,.monaco-editor.hc-light .reference-zone-widget .ref-tree .referenceMatch .highlight{border:1px dotted var(--vscode-contrastActiveBorder,#0000);box-sizing:border-box}.monaco-count-badge{border-radius:11px;box-sizing:border-box;display:inline-block;font-size:11px;font-weight:400;line-height:11px;min-height:18px;min-width:18px;padding:3px 6px;text-align:center}.monaco-count-badge.long{border-radius:2px;line-height:normal;min-height:auto;padding:2px 3px}.monaco-icon-label{display:flex;overflow:hidden;text-overflow:ellipsis}.monaco-icon-label:before{-webkit-font-smoothing:antialiased;-moz-osx-font-smoothing:grayscale;background-position:0;background-repeat:no-repeat;background-size:16px;display:inline-block;flex-shrink:0;height:22px;line-height:inherit!important;padding-right:6px;vertical-align:top;width:16px}.monaco-icon-label-iconpath{display:flex;height:16px;margin-top:2px;padding-left:2px;width:16px}.monaco-icon-label-container.disabled{color:var(--vscode-disabledForeground)}.monaco-icon-label>.monaco-icon-label-container{flex:1 1;min-width:0;overflow:hidden;text-overflow:ellipsis}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-name-container>.label-name{color:inherit;white-space:pre}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-name-container>.label-name>.label-separator{margin:0 2px;opacity:.5}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-suffix-container>.label-suffix{opacity:.7;white-space:pre}.monaco-icon-label>.monaco-icon-label-container>.monaco-icon-description-container>.label-description{font-size:.9em;margin-left:.5em;opacity:.7;white-space:pre}.monaco-icon-label.nowrap>.monaco-icon-label-container>.monaco-icon-description-container>.label-description{white-space:nowrap}.vs .monaco-icon-label>.monaco-icon-label-container>.monaco-icon-description-container>.label-description{opacity:.95}.monaco-icon-label.italic>.monaco-icon-label-container>.monaco-icon-description-container>.label-description,.monaco-icon-label.italic>.monaco-icon-label-container>.monaco-icon-name-container>.label-name{font-style:italic}.monaco-icon-label.deprecated{opacity:.66;text-decoration:line-through}.monaco-icon-label.italic:after{font-style:italic}.monaco-icon-label.strikethrough>.monaco-icon-label-container>.monaco-icon-description-container>.label-description,.monaco-icon-label.strikethrough>.monaco-icon-label-container>.monaco-icon-name-container>.label-name{text-decoration:line-through}.monaco-icon-label:after{font-size:90%;font-weight:600;margin:auto 16px 0 5px;opacity:.75;text-align:center}.monaco-list:focus .selected .monaco-icon-label,.monaco-list:focus .selected .monaco-icon-label:after{color:inherit!important}.monaco-list-row.focused.selected .label-description,.monaco-list-row.selected .label-description{opacity:.8}.monaco-editor .hoverHighlight{background-color:var(--vscode-editor-hoverHighlightBackground)}.monaco-editor .monaco-hover-content{box-sizing:border-box;padding-bottom:2px;padding-right:2px}.monaco-editor .monaco-hover{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);border-radius:3px;color:var(--vscode-editorHoverWidget-foreground)}.monaco-editor .monaco-hover a{color:var(--vscode-textLink-foreground)}.monaco-editor .monaco-hover a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor .monaco-hover .hover-row{display:flex}.monaco-editor .monaco-hover .hover-row .hover-row-contents{display:flex;flex-direction:column;min-width:0}.monaco-editor .monaco-hover .hover-row .verbosity-actions{border-right:1px solid var(--vscode-editorHoverWidget-border);display:flex;flex-direction:column;justify-content:end;padding-left:5px;padding-right:5px}.monaco-editor .monaco-hover .hover-row .verbosity-actions .codicon{cursor:pointer;font-size:11px}.monaco-editor .monaco-hover .hover-row .verbosity-actions .codicon.enabled{color:var(--vscode-textLink-foreground)}.monaco-editor .monaco-hover .hover-row .verbosity-actions .codicon.disabled{opacity:.6}.monaco-editor .monaco-hover .hover-row .actions{background-color:var(--vscode-editorHoverWidget-statusBarBackground)}.monaco-editor .monaco-hover code{background-color:var(--vscode-textCodeBlock-background)}.monaco-editor .diff-hidden-lines-widget{width:100%}.monaco-editor .diff-hidden-lines{font-size:13px;height:0;line-height:14px;transform:translateY(-10px)}.monaco-editor .diff-hidden-lines .bottom.dragging,.monaco-editor .diff-hidden-lines .top.dragging,.monaco-editor .diff-hidden-lines:not(.dragging) .bottom:hover,.monaco-editor .diff-hidden-lines:not(.dragging) .top:hover{background-color:var(--vscode-focusBorder)}.monaco-editor .diff-hidden-lines .bottom,.monaco-editor .diff-hidden-lines .top{background-clip:padding-box;background-color:initial;border-bottom:2px solid #0000;border-top:4px solid #0000;height:4px;transition:background-color .1s ease-out}.monaco-editor .diff-hidden-lines .bottom.canMoveTop:not(.canMoveBottom),.monaco-editor .diff-hidden-lines .top.canMoveTop:not(.canMoveBottom),.monaco-editor.draggingUnchangedRegion.canMoveTop:not(.canMoveBottom) *{cursor:n-resize!important}.monaco-editor .diff-hidden-lines .bottom:not(.canMoveTop).canMoveBottom,.monaco-editor .diff-hidden-lines .top:not(.canMoveTop).canMoveBottom,.monaco-editor.draggingUnchangedRegion:not(.canMoveTop).canMoveBottom *{cursor:s-resize!important}.monaco-editor .diff-hidden-lines .bottom.canMoveTop.canMoveBottom,.monaco-editor .diff-hidden-lines .top.canMoveTop.canMoveBottom,.monaco-editor.draggingUnchangedRegion.canMoveTop.canMoveBottom *{cursor:ns-resize!important}.monaco-editor .diff-hidden-lines .top{transform:translateY(4px)}.monaco-editor .diff-hidden-lines .bottom{transform:translateY(-6px)}.monaco-editor .diff-unchanged-lines{background:var(--vscode-diffEditor-unchangedCodeBackground)}.monaco-editor .noModificationsOverlay{align-items:center;background:var(--vscode-editor-background);display:flex;justify-content:center;z-index:1}.monaco-editor .diff-hidden-lines .center{background:var(--vscode-diffEditor-unchangedRegionBackground);box-shadow:inset 0 -5px 5px -7px var(--vscode-diffEditor-unchangedRegionShadow),inset 0 5px 5px -7px var(--vscode-diffEditor-unchangedRegionShadow);color:var(--vscode-diffEditor-unchangedRegionForeground);display:block;height:24px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-editor .diff-hidden-lines .center span.codicon{vertical-align:middle}.monaco-editor .diff-hidden-lines .center a:hover .codicon{color:var(--vscode-editorLink-activeForeground)!important;cursor:pointer}.monaco-editor .diff-hidden-lines div.breadcrumb-item{cursor:pointer}.monaco-editor .diff-hidden-lines div.breadcrumb-item:hover{color:var(--vscode-editorLink-activeForeground)}.monaco-editor .movedModified,.monaco-editor .movedOriginal{border:2px solid var(--vscode-diffEditor-move-border)}.monaco-editor .movedModified.currentMove,.monaco-editor .movedOriginal.currentMove{border:2px solid var(--vscode-diffEditor-moveActive-border)}.monaco-diff-editor .moved-blocks-lines path.currentMove{stroke:var(--vscode-diffEditor-moveActive-border)}.monaco-diff-editor .moved-blocks-lines path{pointer-events:visiblestroke}.monaco-diff-editor .moved-blocks-lines .arrow{fill:var(--vscode-diffEditor-move-border)}.monaco-diff-editor .moved-blocks-lines .arrow.currentMove{fill:var(--vscode-diffEditor-moveActive-border)}.monaco-diff-editor .moved-blocks-lines .arrow-rectangle{fill:var(--vscode-editor-background)}.monaco-diff-editor .moved-blocks-lines{pointer-events:none;position:absolute}.monaco-diff-editor .moved-blocks-lines path{fill:none;stroke:var(--vscode-diffEditor-move-border);stroke-width:2}.monaco-editor .char-delete.diff-range-empty{border-left:3px solid var(--vscode-diffEditor-removedTextBackground);margin-left:-1px}.monaco-editor .char-insert.diff-range-empty{border-left:3px solid var(--vscode-diffEditor-insertedTextBackground)}.monaco-editor .fold-unchanged{cursor:pointer}.monaco-diff-editor .diff-moved-code-block{display:flex;justify-content:flex-end;margin-top:-4px}.monaco-diff-editor .diff-moved-code-block .action-bar .action-label.codicon{font-size:12px;height:12px;width:12px}.monaco-diff-editor .diffOverview{z-index:9}.monaco-diff-editor .diffOverview .diffViewport{z-index:10}.monaco-diff-editor.vs .diffOverview{background:#00000008}.monaco-diff-editor.vs-dark .diffOverview{background:#ffffff03}.monaco-scrollable-element.modified-in-monaco-diff-editor.vs .scrollbar,.monaco-scrollable-element.modified-in-monaco-diff-editor.vs-dark .scrollbar{background:#0000}.monaco-scrollable-element.modified-in-monaco-diff-editor.hc-black .scrollbar,.monaco-scrollable-element.modified-in-monaco-diff-editor.hc-light .scrollbar{background:none}.monaco-scrollable-element.modified-in-monaco-diff-editor .slider{z-index:10}.modified-in-monaco-diff-editor .slider.active{background:#ababab66}.modified-in-monaco-diff-editor.hc-black .slider.active,.modified-in-monaco-diff-editor.hc-light .slider.active{background:none}.monaco-diff-editor .delete-sign,.monaco-diff-editor .insert-sign,.monaco-editor .delete-sign,.monaco-editor .insert-sign{align-items:center;display:flex!important;font-size:11px!important;opacity:.7!important}.monaco-diff-editor.hc-black .delete-sign,.monaco-diff-editor.hc-black .insert-sign,.monaco-diff-editor.hc-light .delete-sign,.monaco-diff-editor.hc-light .insert-sign,.monaco-editor.hc-black .delete-sign,.monaco-editor.hc-black .insert-sign,.monaco-editor.hc-light .delete-sign,.monaco-editor.hc-light .insert-sign{opacity:1}.monaco-editor .inline-added-margin-view-zone,.monaco-editor .inline-deleted-margin-view-zone{text-align:right}.monaco-editor .arrow-revert-change{position:absolute;z-index:10}.monaco-editor .arrow-revert-change:hover{cursor:pointer}.monaco-editor .view-zones .view-lines .view-line span{display:inline-block}.monaco-editor .margin-view-zones .lightbulb-glyph:hover{cursor:pointer}.monaco-diff-editor .char-insert,.monaco-editor .char-insert{background-color:var(--vscode-diffEditor-insertedTextBackground)}.monaco-diff-editor .line-insert,.monaco-editor .line-insert{background-color:var(--vscode-diffEditor-insertedLineBackground,var(--vscode-diffEditor-insertedTextBackground))}.monaco-editor .char-insert,.monaco-editor .line-insert{border:1px solid var(--vscode-diffEditor-insertedTextBorder);box-sizing:border-box}.monaco-editor.hc-black .char-insert,.monaco-editor.hc-black .line-insert,.monaco-editor.hc-light .char-insert,.monaco-editor.hc-light .line-insert{border-style:dashed}.monaco-editor .char-delete,.monaco-editor .line-delete{border:1px solid var(--vscode-diffEditor-removedTextBorder);box-sizing:border-box}.monaco-editor.hc-black .char-delete,.monaco-editor.hc-black .line-delete,.monaco-editor.hc-light .char-delete,.monaco-editor.hc-light .line-delete{border-style:dashed}.monaco-diff-editor .gutter-insert,.monaco-editor .gutter-insert,.monaco-editor .inline-added-margin-view-zone{background-color:var(--vscode-diffEditorGutter-insertedLineBackground,var(--vscode-diffEditor-insertedLineBackground),var(--vscode-diffEditor-insertedTextBackground))}.monaco-diff-editor .char-delete,.monaco-editor .char-delete,.monaco-editor .inline-deleted-text{background-color:var(--vscode-diffEditor-removedTextBackground)}.monaco-editor .inline-deleted-text{text-decoration:line-through}.monaco-diff-editor .line-delete,.monaco-editor .line-delete{background-color:var(--vscode-diffEditor-removedLineBackground,var(--vscode-diffEditor-removedTextBackground))}.monaco-diff-editor .gutter-delete,.monaco-editor .gutter-delete,.monaco-editor .inline-deleted-margin-view-zone{background-color:var(--vscode-diffEditorGutter-removedLineBackground,var(--vscode-diffEditor-removedLineBackground),var(--vscode-diffEditor-removedTextBackground))}.monaco-diff-editor.side-by-side .editor.modified{border-left:1px solid var(--vscode-diffEditor-border);box-shadow:-6px 0 5px -5px var(--vscode-scrollbar-shadow)}.monaco-diff-editor.side-by-side .editor.original{border-right:1px solid var(--vscode-diffEditor-border);box-shadow:6px 0 5px -5px var(--vscode-scrollbar-shadow)}.monaco-diff-editor .diffViewport{background:var(--vscode-scrollbarSlider-background)}.monaco-diff-editor .diffViewport:hover{background:var(--vscode-scrollbarSlider-hoverBackground)}.monaco-diff-editor .diffViewport:active{background:var(--vscode-scrollbarSlider-activeBackground)}.monaco-editor .diagonal-fill{background-image:linear-gradient(-45deg,var(--vscode-diffEditor-diagonalFill) 12.5%,#0000 12.5%,#0000 50%,var(--vscode-diffEditor-diagonalFill) 50%,var(--vscode-diffEditor-diagonalFill) 62.5%,#0000 62.5%,#0000 100%);background-size:8px 8px}.monaco-diff-editor .gutter{flex-grow:0;flex-shrink:0;overflow:hidden;position:relative;&>div{position:absolute}.gutterItem{opacity:0;transition:opacity .7s;&.showAlways{opacity:1}&.noTransition,&.showAlways{transition:none}}&:hover .gutterItem{opacity:1;transition:opacity .1s ease-in-out}.gutterItem{.background{border-left:2px solid var(--vscode-menu-border);height:100%;left:50%;position:absolute;width:1px}.buttons{align-items:center;display:flex;justify-content:center;position:absolute;width:100%;.monaco-toolbar{height:fit-content;.monaco-action-bar{line-height:1;.actions-container{background:var(--vscode-editorGutter-commentRangeForeground);border-radius:4px;width:fit-content;.action-item{&:hover{background:var(--vscode-toolbar-hoverBackground)}.action-label{padding:1px 2px}}}}}}}}.monaco-diff-editor .diff-hidden-lines-compact{display:flex;height:11px;.line-left,.line-right{border-top:1px solid;border-color:var(--vscode-editorCodeLens-foreground);height:1px;margin:auto;opacity:.5;width:100%}.line-left{width:20px}.text{text-wrap:nowrap;color:var(--vscode-editorCodeLens-foreground);font-size:11px;line-height:11px;margin:0 4px}}.monaco-component.diff-review{user-select:none;-webkit-user-select:none;z-index:99}.monaco-diff-editor .diff-review{position:absolute}.monaco-component.diff-review .diff-review-line-number{color:var(--vscode-editorLineNumber-foreground);display:inline-block;text-align:right}.monaco-component.diff-review .diff-review-summary{padding-left:10px}.monaco-component.diff-review .diff-review-shadow{box-shadow:var(--vscode-scrollbar-shadow) 0 -6px 6px -6px inset;position:absolute}.monaco-component.diff-review .diff-review-row{white-space:pre}.monaco-component.diff-review .diff-review-table{display:table;min-width:100%}.monaco-component.diff-review .diff-review-row{display:table-row;width:100%}.monaco-component.diff-review .diff-review-spacer{display:inline-block;vertical-align:middle;width:10px}.monaco-component.diff-review .diff-review-spacer>.codicon{font-size:9px!important}.monaco-component.diff-review .diff-review-actions{display:inline-block;position:absolute;right:10px;top:2px;z-index:100}.monaco-component.diff-review .diff-review-actions .action-label{height:16px;margin:2px 0;width:16px}.monaco-component.diff-review .revertButton{cursor:pointer}.monaco-editor.hc-light .dnd-target,.monaco-editor.vs .dnd-target{border-right:2px dotted #000;color:#fff}.monaco-editor.vs-dark .dnd-target{border-right:2px dotted #aeafad;color:#51504f}.monaco-editor.hc-black .dnd-target{border-right:2px dotted #fff;color:#000}.monaco-editor.hc-black.mac.mouse-default .view-lines,.monaco-editor.hc-light.mac.mouse-default .view-lines,.monaco-editor.mouse-default .view-lines,.monaco-editor.vs-dark.mac.mouse-default .view-lines{cursor:default}.monaco-editor.hc-black.mac.mouse-copy .view-lines,.monaco-editor.hc-light.mac.mouse-copy .view-lines,.monaco-editor.mouse-copy .view-lines,.monaco-editor.vs-dark.mac.mouse-copy .view-lines{cursor:copy}.monaco-editor .findOptionsWidget{border:2px solid var(--vscode-contrastBorder)}.monaco-editor .find-widget,.monaco-editor .findOptionsWidget{background-color:var(--vscode-editorWidget-background);box-shadow:0 0 8px 2px var(--vscode-widget-shadow);color:var(--vscode-editorWidget-foreground)}.monaco-editor .find-widget{border-bottom:1px solid var(--vscode-widget-border);border-bottom-left-radius:4px;border-bottom-right-radius:4px;border-left:1px solid var(--vscode-widget-border);border-right:1px solid var(--vscode-widget-border);box-sizing:border-box;height:33px;line-height:19px;overflow:hidden;padding:0 4px;position:absolute;transform:translateY(calc(-100% - 10px));transition:transform .2s linear;z-index:35}.monaco-workbench.reduce-motion .monaco-editor .find-widget{transition:transform 0ms linear}.monaco-editor .find-widget textarea{margin:0}.monaco-editor .find-widget.hiddenEditor{display:none}.monaco-editor .find-widget.replaceToggled>.replace-part{display:flex}.monaco-editor .find-widget.visible{transform:translateY(0)}.monaco-editor .find-widget .monaco-inputbox.synthetic-focus{outline:1px solid -webkit-focus-ring-color;outline-color:var(--vscode-focusBorder);outline-offset:-1px}.monaco-editor .find-widget .monaco-inputbox .input{background-color:initial;min-height:0}.monaco-editor .find-widget .monaco-findInput .input{font-size:13px}.monaco-editor .find-widget>.find-part,.monaco-editor .find-widget>.replace-part{display:flex;font-size:12px;margin:3px 25px 0 17px}.monaco-editor .find-widget>.find-part .monaco-inputbox,.monaco-editor .find-widget>.replace-part .monaco-inputbox{min-height:25px}.monaco-editor .find-widget>.replace-part .monaco-inputbox>.ibwrapper>.mirror{padding-right:22px}.monaco-editor .find-widget>.find-part .monaco-inputbox>.ibwrapper>.input,.monaco-editor .find-widget>.find-part .monaco-inputbox>.ibwrapper>.mirror,.monaco-editor .find-widget>.replace-part .monaco-inputbox>.ibwrapper>.input,.monaco-editor .find-widget>.replace-part .monaco-inputbox>.ibwrapper>.mirror{padding-bottom:2px;padding-top:2px}.monaco-editor .find-widget>.find-part .find-actions,.monaco-editor .find-widget>.replace-part .replace-actions{align-items:center;display:flex;height:25px}.monaco-editor .find-widget .monaco-findInput{display:flex;flex:1 1;vertical-align:middle}.monaco-editor .find-widget .monaco-findInput .monaco-scrollable-element{width:100%}.monaco-editor .find-widget .monaco-findInput .monaco-scrollable-element .scrollbar.vertical{opacity:0}.monaco-editor .find-widget .matchesCount{box-sizing:border-box;display:flex;flex:initial;height:25px;line-height:23px;margin:0 0 0 3px;padding:2px 0 0 2px;text-align:center;vertical-align:middle}.monaco-editor .find-widget .button{align-items:center;background-position:50%;background-repeat:no-repeat;border-radius:5px;cursor:pointer;display:flex;flex:initial;height:16px;justify-content:center;margin-left:3px;padding:3px;width:16px}.monaco-editor .find-widget .codicon-find-selection{border-radius:5px;height:22px;padding:3px;width:22px}.monaco-editor .find-widget .button.left{margin-left:0;margin-right:3px}.monaco-editor .find-widget .button.wide{padding:1px 6px;top:-1px;width:auto}.monaco-editor .find-widget .button.toggle{border-radius:0;box-sizing:border-box;height:100%;left:3px;position:absolute;top:0;width:18px}.monaco-editor .find-widget .button.toggle.disabled{display:none}.monaco-editor .find-widget .disabled{color:var(--vscode-disabledForeground);cursor:default}.monaco-editor .find-widget>.replace-part{display:none}.monaco-editor .find-widget>.replace-part>.monaco-findInput{display:flex;flex:auto;flex-grow:0;flex-shrink:0;position:relative;vertical-align:middle}.monaco-editor .find-widget>.replace-part>.monaco-findInput>.controls{position:absolute;right:2px;top:3px}.monaco-editor .find-widget.reduced-find-widget .matchesCount{display:none}.monaco-editor .find-widget.narrow-find-widget{max-width:257px!important}.monaco-editor .find-widget.collapsed-find-widget{max-width:170px!important}.monaco-editor .find-widget.collapsed-find-widget .button.next,.monaco-editor .find-widget.collapsed-find-widget .button.previous,.monaco-editor .find-widget.collapsed-find-widget .button.replace,.monaco-editor .find-widget.collapsed-find-widget .button.replace-all,.monaco-editor .find-widget.collapsed-find-widget>.find-part .monaco-findInput .controls{display:none}.monaco-editor .find-widget.no-results .matchesCount{color:var(--vscode-errorForeground)}.monaco-editor .findMatch{animation-duration:0;animation-name:inherit!important;background-color:var(--vscode-editor-findMatchHighlightBackground)}.monaco-editor .currentFindMatch{background-color:var(--vscode-editor-findMatchBackground);border:2px solid var(--vscode-editor-findMatchBorder);box-sizing:border-box;padding:1px}.monaco-editor .findScope{background-color:var(--vscode-editor-findRangeHighlightBackground)}.monaco-editor .find-widget .monaco-sash{background-color:var(--vscode-editorWidget-resizeBorder,var(--vscode-editorWidget-border));left:0!important}.monaco-editor.hc-black .find-widget .button:before{left:2px;position:relative;top:1px}.monaco-editor .find-widget .button:not(.disabled):hover,.monaco-editor .find-widget .codicon-find-selection:hover{background-color:var(--vscode-toolbar-hoverBackground)!important}.monaco-editor.findMatch{background-color:var(--vscode-editor-findMatchHighlightBackground)}.monaco-editor.currentFindMatch{background-color:var(--vscode-editor-findMatchBackground)}.monaco-editor.findScope{background-color:var(--vscode-editor-findRangeHighlightBackground)}.monaco-editor.findMatch{background-color:var(--vscode-editorWidget-background)}.monaco-editor .find-widget>.button.codicon-widget-close{position:absolute;right:4px;top:5px}.monaco-editor .margin-view-overlays .codicon-folding-collapsed,.monaco-editor .margin-view-overlays .codicon-folding-expanded,.monaco-editor .margin-view-overlays .codicon-folding-manual-collapsed,.monaco-editor .margin-view-overlays .codicon-folding-manual-expanded{align-items:center;cursor:pointer;display:flex;font-size:140%;justify-content:center;margin-left:2px;opacity:0;transition:opacity .5s}.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-collapsed,.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-expanded,.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-manual-collapsed,.monaco-workbench.reduce-motion .monaco-editor .margin-view-overlays .codicon-folding-manual-expanded{transition:initial}.monaco-editor .margin-view-overlays .codicon.alwaysShowFoldIcons,.monaco-editor .margin-view-overlays .codicon.codicon-folding-collapsed,.monaco-editor .margin-view-overlays .codicon.codicon-folding-manual-collapsed,.monaco-editor .margin-view-overlays:hover .codicon{opacity:1}.monaco-editor .inline-folded:after{color:var(--vscode-editor-foldPlaceholderForeground);content:"\22EF";cursor:pointer;display:inline;line-height:1em;margin:.1em .2em 0}.monaco-editor .folded-background{background-color:var(--vscode-editor-foldBackground)}.monaco-editor .cldr.codicon.codicon-folding-collapsed,.monaco-editor .cldr.codicon.codicon-folding-expanded,.monaco-editor .cldr.codicon.codicon-folding-manual-collapsed,.monaco-editor .cldr.codicon.codicon-folding-manual-expanded{color:var(--vscode-editorGutter-foldingControlForeground)!important}.monaco-editor .peekview-widget .head .peekview-title .severity-icon{display:inline-block;margin-right:4px;vertical-align:text-top}.monaco-editor .marker-widget{text-overflow:ellipsis;white-space:nowrap}.monaco-editor .marker-widget>.stale{font-style:italic;opacity:.6}.monaco-editor .marker-widget .title{display:inline-block;padding-right:5px}.monaco-editor .marker-widget .descriptioncontainer{padding:8px 12px 0 20px;position:absolute;user-select:text;-webkit-user-select:text;white-space:pre}.monaco-editor .marker-widget .descriptioncontainer .message{display:flex;flex-direction:column}.monaco-editor .marker-widget .descriptioncontainer .message .details{padding-left:6px}.monaco-editor .marker-widget .descriptioncontainer .message .source,.monaco-editor .marker-widget .descriptioncontainer .message span.code{opacity:.6}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link{color:inherit;opacity:.6}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link:before{content:"("}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link:after{content:")"}.monaco-editor .marker-widget .descriptioncontainer .message a.code-link>span{border-bottom:1px solid #0000;color:var(--vscode-textLink-activeForeground);text-decoration:underline;text-underline-position:under}.monaco-editor .marker-widget .descriptioncontainer .filename{color:var(--vscode-textLink-activeForeground);cursor:pointer}.extension-editor .codicon.codicon-error,.extensions-viewlet>.extensions .codicon.codicon-error,.markers-panel .marker-icon .codicon.codicon-error,.markers-panel .marker-icon.error,.monaco-editor .zone-widget .codicon.codicon-error,.preferences-editor .codicon.codicon-error,.text-search-provider-messages .providerMessage .codicon.codicon-error{color:var(--vscode-problemsErrorIcon-foreground)}.extension-editor .codicon.codicon-warning,.extensions-viewlet>.extensions .codicon.codicon-warning,.markers-panel .marker-icon .codicon.codicon-warning,.markers-panel .marker-icon.warning,.monaco-editor .zone-widget .codicon.codicon-warning,.preferences-editor .codicon.codicon-warning,.text-search-provider-messages .providerMessage .codicon.codicon-warning{color:var(--vscode-problemsWarningIcon-foreground)}.extension-editor .codicon.codicon-info,.extensions-viewlet>.extensions .codicon.codicon-info,.markers-panel .marker-icon .codicon.codicon-info,.markers-panel .marker-icon.info,.monaco-editor .zone-widget .codicon.codicon-info,.preferences-editor .codicon.codicon-info,.text-search-provider-messages .providerMessage .codicon.codicon-info{color:var(--vscode-problemsInfoIcon-foreground)}.monaco-editor .goto-definition-link{color:var(--vscode-editorLink-activeForeground)!important;cursor:pointer;text-decoration:underline}.monaco-editor .iPadShowKeyboard{background:url(data:image/svg+xml;base64,PHN2ZyB3aWR0aD0iNTMiIGhlaWdodD0iMzYiIGZpbGw9Im5vbmUiIHhtbG5zPSJodHRwOi8vd3d3LnczLm9yZy8yMDAwL3N2ZyI+PGcgY2xpcC1wYXRoPSJ1cmwoI2EpIj48cGF0aCBmaWxsLXJ1bGU9ImV2ZW5vZGQiIGNsaXAtcnVsZT0iZXZlbm9kZCIgZD0iTTQ4LjAzNiA0LjAxSDQuMDA4VjMyLjAzaDQ0LjAyOFY0LjAxWk00LjAwOC4wMDhBNC4wMDMgNC4wMDMgMCAwIDAgLjAwNSA0LjAxVjMyLjAzYTQuMDAzIDQuMDAzIDAgMCAwIDQuMDAzIDQuMDAyaDQ0LjAyOGE0LjAwMyA0LjAwMyAwIDAgMCA0LjAwMy00LjAwMlY0LjAxQTQuMDAzIDQuMDAzIDAgMCAwIDQ4LjAzNi4wMDhINC4wMDhaTTguMDEgOC4wMTNoNC4wMDN2NC4wMDNIOC4wMVY4LjAxM1ptMTIuMDA4IDBoLTQuMDAydjQuMDAzaDQuMDAyVjguMDEzWm00LjAwMyAwaDQuMDAydjQuMDAzaC00LjAwMlY4LjAxM1ptMTIuMDA4IDBoLTQuMDAzdjQuMDAzaDQuMDAzVjguMDEzWm00LjAwMiAwaDQuMDAzdjQuMDAzSDQwLjAzVjguMDEzWm0tMjQuMDE1IDguMDA1SDguMDF2NC4wMDNoOC4wMDZ2LTQuMDAzWm00LjAwMiAwaDQuMDAzdjQuMDAzaC00LjAwM3YtNC4wMDNabTEyLjAwOCAwaC00LjAwM3Y0LjAwM2g0LjAwM3YtNC4wMDNabTEyLjAwOCAwdjQuMDAzaC04LjAwNXYtNC4wMDNoOC4wMDVabS0zMi4wMjEgOC4wMDVIOC4wMXY0LjAwM2g0LjAwM3YtNC4wMDNabTQuMDAzIDBoMjAuMDEzdjQuMDAzSDE2LjAxNnYtNC4wMDNabTI4LjAxOCAwSDQwLjAzdjQuMDAzaDQuMDAzdi00LjAwM1oiIGZpbGw9IiM0MjQyNDIiLz48L2c+PGRlZnM+PGNsaXBQYXRoIGlkPSJhIj48cGF0aCBmaWxsPSIjZmZmIiBkPSJNMCAwaDUzdjM2SDB6Ii8+PC9jbGlwUGF0aD48L2RlZnM+PC9zdmc+) 50% no-repeat;border:4px solid #f6f6f6;border-radius:4px;height:36px;margin:0;min-height:0;min-width:0;overflow:hidden;padding:0;position:absolute;resize:none;width:58px}.monaco-editor.vs-dark .iPadShowKeyboard{background:url(data:image/svg+xml;base64,PHN2ZyB3aWR0aD0iNTMiIGhlaWdodD0iMzYiIGZpbGw9Im5vbmUiIHhtbG5zPSJodHRwOi8vd3d3LnczLm9yZy8yMDAwL3N2ZyI+PGcgY2xpcC1wYXRoPSJ1cmwoI2EpIj48cGF0aCBmaWxsLXJ1bGU9ImV2ZW5vZGQiIGNsaXAtcnVsZT0iZXZlbm9kZCIgZD0iTTQ4LjAzNiA0LjAxSDQuMDA4VjMyLjAzaDQ0LjAyOFY0LjAxWk00LjAwOC4wMDhBNC4wMDMgNC4wMDMgMCAwIDAgLjAwNSA0LjAxVjMyLjAzYTQuMDAzIDQuMDAzIDAgMCAwIDQuMDAzIDQuMDAyaDQ0LjAyOGE0LjAwMyA0LjAwMyAwIDAgMCA0LjAwMy00LjAwMlY0LjAxQTQuMDAzIDQuMDAzIDAgMCAwIDQ4LjAzNi4wMDhINC4wMDhaTTguMDEgOC4wMTNoNC4wMDN2NC4wMDNIOC4wMVY4LjAxM1ptMTIuMDA4IDBoLTQuMDAydjQuMDAzaDQuMDAyVjguMDEzWm00LjAwMyAwaDQuMDAydjQuMDAzaC00LjAwMlY4LjAxM1ptMTIuMDA4IDBoLTQuMDAzdjQuMDAzaDQuMDAzVjguMDEzWm00LjAwMiAwaDQuMDAzdjQuMDAzSDQwLjAzVjguMDEzWm0tMjQuMDE1IDguMDA1SDguMDF2NC4wMDNoOC4wMDZ2LTQuMDAzWm00LjAwMiAwaDQuMDAzdjQuMDAzaC00LjAwM3YtNC4wMDNabTEyLjAwOCAwaC00LjAwM3Y0LjAwM2g0LjAwM3YtNC4wMDNabTEyLjAwOCAwdjQuMDAzaC04LjAwNXYtNC4wMDNoOC4wMDVabS0zMi4wMjEgOC4wMDVIOC4wMXY0LjAwM2g0LjAwM3YtNC4wMDNabTQuMDAzIDBoMjAuMDEzdjQuMDAzSDE2LjAxNnYtNC4wMDNabTI4LjAxOCAwSDQwLjAzdjQuMDAzaDQuMDAzdi00LjAwM1oiIGZpbGw9IiNDNUM1QzUiLz48L2c+PGRlZnM+PGNsaXBQYXRoIGlkPSJhIj48cGF0aCBmaWxsPSIjZmZmIiBkPSJNMCAwaDUzdjM2SDB6Ii8+PC9jbGlwUGF0aD48L2RlZnM+PC9zdmc+) 50% no-repeat;border:4px solid #252526}.monaco-editor.vs .valueSetReplacement{outline:solid 2px var(--vscode-editorBracketMatch-border)}.monaco-editor .suggest-preview-additional-widget{white-space:nowrap}.monaco-editor .suggest-preview-additional-widget .content-spacer{color:#0000;white-space:pre}.monaco-editor .suggest-preview-additional-widget .button{cursor:pointer;display:inline-block;text-decoration:underline;text-underline-position:under}.monaco-editor .ghost-text-hidden{font-size:0;opacity:0}.monaco-editor .ghost-text-decoration,.monaco-editor .suggest-preview-text .ghost-text{font-style:italic}.monaco-editor .ghost-text-decoration,.monaco-editor .ghost-text-decoration-preview,.monaco-editor .suggest-preview-text .ghost-text{background-color:var(--vscode-editorGhostText-background);border:1px solid var(--vscode-editorGhostText-border);color:var(--vscode-editorGhostText-foreground)!important}.monaco-editor .snippet-placeholder{background-color:var(--vscode-editor-snippetTabstopHighlightBackground,#0000);min-width:2px;outline-color:var(--vscode-editor-snippetTabstopHighlightBorder,#0000);outline-style:solid;outline-width:1px}.monaco-editor .finish-snippet-placeholder{background-color:var(--vscode-editor-snippetFinalTabstopHighlightBackground,#0000);outline-color:var(--vscode-editor-snippetFinalTabstopHighlightBorder,#0000);outline-style:solid;outline-width:1px}.monaco-editor .suggest-widget{border-radius:3px;display:flex;flex-direction:column;width:430px;z-index:40}.monaco-editor .suggest-widget.message{align-items:center;flex-direction:row}.monaco-editor .suggest-details,.monaco-editor .suggest-widget{background-color:var(--vscode-editorSuggestWidget-background);border-color:var(--vscode-editorSuggestWidget-border);border-style:solid;border-width:1px;flex:0 1 auto;width:100%}.monaco-editor.hc-black .suggest-details,.monaco-editor.hc-black .suggest-widget,.monaco-editor.hc-light .suggest-details,.monaco-editor.hc-light .suggest-widget{border-width:2px}.monaco-editor .suggest-widget .suggest-status-bar{border-top:1px solid var(--vscode-editorSuggestWidget-border);box-sizing:border-box;display:none;flex-flow:row nowrap;font-size:80%;justify-content:space-between;overflow:hidden;padding:0 4px;width:100%}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar{display:flex}.monaco-editor .suggest-widget .suggest-status-bar .left{padding-right:8px}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar .action-label{color:var(--vscode-editorSuggestWidgetStatus-foreground)}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar .action-item:not(:last-of-type) .action-label{margin-right:0}.monaco-editor .suggest-widget.with-status-bar .suggest-status-bar .action-item:not(:last-of-type) .action-label:after{content:", ";margin-right:.3em}.monaco-editor .suggest-widget.with-status-bar .monaco-list .monaco-list-row.focused.string-label>.contents>.main>.right>.readMore,.monaco-editor .suggest-widget.with-status-bar .monaco-list .monaco-list-row>.contents>.main>.right>.readMore{display:none}.monaco-editor .suggest-widget.with-status-bar:not(.docs-side) .monaco-list .monaco-list-row:hover>.contents>.main>.right.can-expand-details>.details-label{width:100%}.monaco-editor .suggest-widget>.message{padding-left:22px}.monaco-editor .suggest-widget>.tree{height:100%;width:100%}.monaco-editor .suggest-widget .monaco-list{user-select:none;-webkit-user-select:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row{background-position:2px 2px;background-repeat:no-repeat;-mox-box-sizing:border-box;box-sizing:border-box;cursor:pointer;display:flex;padding-right:10px;touch-action:none;white-space:nowrap}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused{color:var(--vscode-editorSuggestWidget-selectedForeground)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused .codicon{color:var(--vscode-editorSuggestWidget-selectedIconForeground)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents{flex:1 1;height:100%;overflow:hidden;padding-left:2px}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main{display:flex;justify-content:space-between;overflow:hidden;text-overflow:ellipsis;white-space:pre}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left,.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right{display:flex}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.focused)>.contents>.main .monaco-icon-label{color:var(--vscode-editorSuggestWidget-foreground)}.monaco-editor .suggest-widget:not(.frozen) .monaco-highlighted-label .highlight{font-weight:700}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main .monaco-highlighted-label .highlight{color:var(--vscode-editorSuggestWidget-highlightForeground)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused>.contents>.main .monaco-highlighted-label .highlight{color:var(--vscode-editorSuggestWidget-focusHighlightForeground)}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.codicon-close,.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.readMore:before{color:inherit;cursor:pointer;font-size:14px;opacity:1}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.codicon-close{position:absolute;right:2px;top:6px}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.codicon-close:hover,.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.readMore:hover{opacity:1}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label{opacity:.7}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left>.signature-label{opacity:.6;overflow:hidden;text-overflow:ellipsis}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left>.qualifier-label{align-self:center;font-size:85%;line-height:normal;margin-left:12px;opacity:.4;overflow:hidden;text-overflow:ellipsis}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label{font-size:85%;margin-left:1.1em;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label>.monaco-tokenized-source{display:inline}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.details-label{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.string-label)>.contents>.main>.right>.details-label,.monaco-editor .suggest-widget.docs-side .monaco-list .monaco-list-row.focused:not(.string-label)>.contents>.main>.right>.details-label,.monaco-editor .suggest-widget:not(.shows-details) .monaco-list .monaco-list-row.focused>.contents>.main>.right>.details-label{display:inline}.monaco-editor .suggest-widget:not(.docs-side) .monaco-list .monaco-list-row.focused:hover>.contents>.main>.right.can-expand-details>.details-label{width:calc(100% - 26px)}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left{flex-grow:1;flex-shrink:1;overflow:hidden}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.left>.monaco-icon-label{flex-shrink:0}.monaco-editor .suggest-widget .monaco-list .monaco-list-row:not(.string-label)>.contents>.main>.left>.monaco-icon-label{max-width:100%}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.string-label>.contents>.main>.left>.monaco-icon-label{flex-shrink:1}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right{flex-shrink:4;max-width:70%;overflow:hidden}.monaco-editor .suggest-widget .monaco-list .monaco-list-row>.contents>.main>.right>.readMore{display:inline-block;height:18px;position:absolute;right:10px;visibility:hidden;width:18px}.monaco-editor .suggest-widget.docs-side .monaco-list .monaco-list-row>.contents>.main>.right>.readMore{display:none!important}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.string-label>.contents>.main>.right>.readMore{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused.string-label>.contents>.main>.right>.readMore{display:inline-block}.monaco-editor .suggest-widget .monaco-list .monaco-list-row.focused:hover>.contents>.main>.right>.readMore{visibility:visible}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .monaco-icon-label.deprecated{opacity:.66;text-decoration:unset}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .monaco-icon-label.deprecated>.monaco-icon-label-container>.monaco-icon-name-container{text-decoration:line-through}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .monaco-icon-label:before{height:100%}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .icon{background-position:50%;background-repeat:no-repeat;background-size:80%;display:block;height:16px;margin-left:2px;width:16px}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .icon.hide{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .suggest-icon{align-items:center;display:flex;margin-right:4px}.monaco-editor .suggest-widget.no-icons .monaco-list .monaco-list-row .icon,.monaco-editor .suggest-widget.no-icons .monaco-list .monaco-list-row .suggest-icon:before{display:none}.monaco-editor .suggest-widget .monaco-list .monaco-list-row .icon.customcolor .colorspan{border:.1em solid #000;display:inline-block;height:.7em;margin:0 0 0 .3em;width:.7em}.monaco-editor .suggest-details-container{z-index:41}.monaco-editor .suggest-details{color:var(--vscode-editorSuggestWidget-foreground);cursor:default;display:flex;flex-direction:column}.monaco-editor .suggest-details.focused{border-color:var(--vscode-focusBorder)}.monaco-editor .suggest-details a{color:var(--vscode-textLink-foreground)}.monaco-editor .suggest-details a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor .suggest-details code{background-color:var(--vscode-textCodeBlock-background)}.monaco-editor .suggest-details.no-docs{display:none}.monaco-editor .suggest-details>.monaco-scrollable-element{flex:1 1}.monaco-editor .suggest-details>.monaco-scrollable-element>.body{box-sizing:border-box;height:100%;width:100%}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.type{flex:2 1;margin:0 24px 0 0;opacity:.7;overflow:hidden;padding:4px 0 12px 5px;text-overflow:ellipsis;white-space:pre}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.header>.type.auto-wrap{white-space:normal;word-break:break-all}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs{margin:0;padding:4px 5px;white-space:pre-wrap}.monaco-editor .suggest-details.no-type>.monaco-scrollable-element>.body>.docs{margin-right:24px;overflow:hidden}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs{min-height:calc(1rem + 8px);padding:0;white-space:normal}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>div,.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>span:not(:empty){padding:4px 5px}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>div>p:first-child{margin-top:0}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs>div>p:last-child{margin-bottom:0}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs .monaco-tokenized-source{white-space:pre}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs .code{word-wrap:break-word;white-space:pre-wrap}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>.docs.markdown-docs .codicon{vertical-align:sub}.monaco-editor .suggest-details>.monaco-scrollable-element>.body>p:empty{display:none}.monaco-editor .suggest-details code{border-radius:3px;padding:0 .4em}.monaco-editor .suggest-details ol,.monaco-editor .suggest-details ul{padding-left:20px}.monaco-editor .suggest-details p code{font-family:var(--monaco-monospace-font)}.monaco-editor .inline-edit-remove{background-color:var(--vscode-editorGhostText-background);font-style:italic}.monaco-editor .inline-edit-hidden{font-size:0;opacity:0}.monaco-editor .inline-edit-decoration,.monaco-editor .suggest-preview-text .inline-edit{font-style:italic}.monaco-editor .inline-completion-text-to-replace{text-decoration:underline;text-underline-position:under}.monaco-editor .inline-edit-decoration,.monaco-editor .inline-edit-decoration-preview,.monaco-editor .suggest-preview-text .inline-edit{background-color:var(--vscode-editorGhostText-background);border:1px solid var(--vscode-editorGhostText-border);color:var(--vscode-editorGhostText-foreground)!important}.monaco-editor .inlineEditHints.withBorder{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);z-index:39}.monaco-editor .inlineEditHints a,.monaco-editor .inlineEditHints a:hover{color:var(--vscode-foreground)}.monaco-editor .inlineEditHints .keybinding{display:flex;margin-left:4px;opacity:.6}.monaco-editor .inlineEditHints .keybinding .monaco-keybinding-key{font-size:8px;padding:2px 3px}.monaco-editor .inlineEditStatusBarItemLabel{margin-right:2px}.monaco-editor .inlineEditSideBySide{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);white-space:pre;z-index:39}.monaco-editor div.inline-edits-widget{--widget-color:var(--vscode-notifications-background);.promptEditor .monaco-editor{--vscode-editor-placeholder-foreground:var(--vscode-editorGhostText-foreground)}.promptEditor,.toolbar{opacity:0;transition:opacity .2s ease-in-out}&.focused,&:hover{.promptEditor,.toolbar{opacity:1}}.preview .monaco-editor{--vscode-editor-background:var(--widget-color);.mtk1{color:var(--vscode-editorGhostText-foreground)}.current-line-margin,.view-overlays .current-line-exact{border:none}}svg{.gradient-start{stop-color:var(--vscode-editor-background)}.gradient-stop{stop-color:var(--widget-color)}}}.monaco-editor .tokens-inspect-widget{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);padding:10px;user-select:text;-webkit-user-select:text;z-index:50}.monaco-editor.hc-black .tokens-inspect-widget,.monaco-editor.hc-light .tokens-inspect-widget{border-width:2px}.monaco-editor .tokens-inspect-widget .tokens-inspect-separator{background-color:var(--vscode-editorHoverWidget-border);border:0;height:1px}.monaco-editor .tokens-inspect-widget .tm-token{font-family:var(--monaco-monospace-font)}.monaco-editor .tokens-inspect-widget .tm-token-length{float:right;font-size:60%;font-weight:400}.monaco-editor .tokens-inspect-widget .tm-metadata-table{width:100%}.monaco-editor .tokens-inspect-widget .tm-metadata-value{font-family:var(--monaco-monospace-font);text-align:right}.monaco-editor .tokens-inspect-widget .tm-token-type{font-family:var(--monaco-monospace-font)}.monaco-editor .linked-editing-decoration{background-color:var(--vscode-editor-linkedEditingBackground);min-width:1px}.monaco-editor .detected-link,.monaco-editor .detected-link-active{text-decoration:underline;text-underline-position:under}.monaco-editor .detected-link-active{color:var(--vscode-editorLink-activeForeground)!important;cursor:pointer}.monaco-editor .focused .selectionHighlight{background-color:var(--vscode-editor-selectionHighlightBackground);border:1px solid var(--vscode-editor-selectionHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .focused .selectionHighlight,.monaco-editor.hc-light .focused .selectionHighlight{border-style:dotted}.monaco-editor .wordHighlight{background-color:var(--vscode-editor-wordHighlightBackground);border:1px solid var(--vscode-editor-wordHighlightBorder);box-sizing:border-box}.monaco-editor.hc-black .wordHighlight,.monaco-editor.hc-light .wordHighlight{border-style:dotted}.monaco-editor .wordHighlightStrong{background-color:var(--vscode-editor-wordHighlightStrongBackground);border:1px solid var(--vscode-editor-wordHighlightStrongBorder);box-sizing:border-box}.monaco-editor.hc-black .wordHighlightStrong,.monaco-editor.hc-light .wordHighlightStrong{border-style:dotted}.monaco-editor .wordHighlightText{background-color:var(--vscode-editor-wordHighlightTextBackground);border:1px solid var(--vscode-editor-wordHighlightTextBorder);box-sizing:border-box}.monaco-editor.hc-black .wordHighlightText,.monaco-editor.hc-light .wordHighlightText{border-style:dotted}.monaco-editor .parameter-hints-widget{background-color:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);color:var(--vscode-editorHoverWidget-foreground);cursor:default;display:flex;flex-direction:column;line-height:1.5em;z-index:39}.hc-black .monaco-editor .parameter-hints-widget,.hc-light .monaco-editor .parameter-hints-widget{border-width:2px}.monaco-editor .parameter-hints-widget>.phwrapper{display:flex;flex-direction:row;max-width:440px}.monaco-editor .parameter-hints-widget.multiple{min-height:3.3em;padding:0}.monaco-editor .parameter-hints-widget.multiple .body:before{border-left:1px solid var(--vscode-editorHoverWidget-border);content:"";display:block;height:100%;opacity:.5;position:absolute}.monaco-editor .parameter-hints-widget p,.monaco-editor .parameter-hints-widget ul{margin:8px 0}.monaco-editor .parameter-hints-widget .body,.monaco-editor .parameter-hints-widget .monaco-scrollable-element{display:flex;flex:1 1;flex-direction:column;min-height:100%}.monaco-editor .parameter-hints-widget .signature{padding:4px 5px;position:relative}.monaco-editor .parameter-hints-widget .signature.has-docs:after{border-bottom:1px solid var(--vscode-editorHoverWidget-border);content:"";display:block;left:0;opacity:.5;padding-top:4px;position:absolute;width:100%}.monaco-editor .parameter-hints-widget .code{font-family:var(--vscode-parameterHintsWidget-editorFontFamily),var(--vscode-parameterHintsWidget-editorFontFamilyDefault)}.monaco-editor .parameter-hints-widget .docs{padding:0 10px 0 5px;white-space:pre-wrap}.monaco-editor .parameter-hints-widget .docs.empty{display:none}.monaco-editor .parameter-hints-widget .docs a{color:var(--vscode-textLink-foreground)}.monaco-editor .parameter-hints-widget .docs a:hover{color:var(--vscode-textLink-activeForeground);cursor:pointer}.monaco-editor .parameter-hints-widget .docs .markdown-docs{white-space:normal}.monaco-editor .parameter-hints-widget .docs code{background-color:var(--vscode-textCodeBlock-background);border-radius:3px;font-family:var(--monaco-monospace-font);padding:0 .4em}.monaco-editor .parameter-hints-widget .docs .code,.monaco-editor .parameter-hints-widget .docs .monaco-tokenized-source{white-space:pre-wrap}.monaco-editor .parameter-hints-widget .controls{align-items:center;display:none;flex-direction:column;justify-content:flex-end;min-width:22px}.monaco-editor .parameter-hints-widget.multiple .controls{display:flex;padding:0 2px}.monaco-editor .parameter-hints-widget.multiple .button{background-repeat:no-repeat;cursor:pointer;height:16px;width:16px}.monaco-editor .parameter-hints-widget .button.previous{bottom:24px}.monaco-editor .parameter-hints-widget .overloads{font-family:var(--monaco-monospace-font);height:12px;line-height:12px;text-align:center}.monaco-editor .parameter-hints-widget .signature .parameter.active{color:var(--vscode-editorHoverWidget-highlightForeground);font-weight:700}.monaco-editor .parameter-hints-widget .documentation-parameter>.parameter{font-weight:700;margin-right:.5em}.monaco-editor{--vscode-editor-placeholder-foreground:var(--vscode-editorGhostText-foreground);.editorPlaceholder{text-wrap:nowrap;color:var(--vscode-editor-placeholder-foreground);overflow:hidden;pointer-events:none;position:absolute;text-overflow:ellipsis;top:0}}.monaco-editor .rename-box{border-radius:4px;color:inherit;z-index:100}.monaco-editor .rename-box.preview{padding:4px 4px 0}.monaco-editor .rename-box .rename-input-with-button{border-radius:2px;padding:3px;width:calc(100% - 8px)}.monaco-editor .rename-box .rename-input{padding:0;width:calc(100% - 8px)}.monaco-editor .rename-box .rename-input:focus{outline:none}.monaco-editor .rename-box .rename-suggestions-button{align-items:center;background-color:initial;border:none;border-radius:5px;cursor:pointer;display:flex;padding:3px}.monaco-editor .rename-box .rename-suggestions-button:hover{background-color:var(--vscode-toolbar-hoverBackground)}.monaco-editor .rename-box .rename-candidate-list-container .monaco-list-row{border-radius:2px}.monaco-editor .rename-box .rename-label{display:none;opacity:.8}.monaco-editor .rename-box.preview .rename-label{display:inherit}.monaco-editor .sticky-widget{overflow:hidden}.monaco-editor .sticky-widget-line-numbers{background-color:inherit;float:left}.monaco-editor .sticky-widget-lines-scrollable{background-color:inherit;display:inline-block;overflow:hidden;position:absolute;width:var(--vscode-editorStickyScroll-scrollableWidth)}.monaco-editor .sticky-widget-lines{background-color:inherit;position:absolute}.monaco-editor .sticky-line-content,.monaco-editor .sticky-line-number{background-color:inherit;color:var(--vscode-editorLineNumber-foreground);display:inline-block;position:absolute;white-space:nowrap}.monaco-editor .sticky-line-number .codicon-folding-collapsed,.monaco-editor .sticky-line-number .codicon-folding-expanded{float:right;transition:var(--vscode-editorStickyScroll-foldingOpacityTransition)}.monaco-editor .sticky-line-content{background-color:inherit;white-space:nowrap;width:var(--vscode-editorStickyScroll-scrollableWidth)}.monaco-editor .sticky-line-number-inner{display:inline-block;text-align:right}.monaco-editor .sticky-widget{border-bottom:1px solid var(--vscode-editorStickyScroll-border)}.monaco-editor .sticky-line-content:hover{background-color:var(--vscode-editorStickyScrollHover-background);cursor:pointer}.monaco-editor .sticky-widget{background-color:var(--vscode-editorStickyScroll-background);box-shadow:var(--vscode-editorStickyScroll-shadow) 0 4px 2px -2px;right:auto!important;width:100%;z-index:4}.monaco-editor .sticky-widget.peek{background-color:var(--vscode-peekViewEditorStickyScroll-background)}.monaco-editor .unicode-highlight{background-color:var(--vscode-editorUnicodeHighlight-background);border:1px solid var(--vscode-editorUnicodeHighlight-border);box-sizing:border-box}.editor-banner{background:var(--vscode-banner-background);box-sizing:border-box;cursor:default;display:flex;font-size:12px;height:26px;overflow:visible;width:100%}.editor-banner .icon-container{align-items:center;display:flex;flex-shrink:0;padding:0 6px 0 10px}.editor-banner .icon-container.custom-icon{background-position:50%;background-repeat:no-repeat;background-size:16px;margin:0 6px 0 10px;padding:0;width:16px}.editor-banner .message-container{align-items:center;display:flex;line-height:26px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.editor-banner .message-container p{margin-block-end:0;margin-block-start:0}.editor-banner .message-actions-container{flex-grow:1;flex-shrink:0;line-height:26px;margin:0 4px}.editor-banner .message-actions-container a.monaco-button{margin:2px 8px;padding:0 12px;width:inherit}.editor-banner .message-actions-container a{margin-left:12px;padding:3px;text-decoration:underline}.editor-banner .action-container{padding:0 10px 0 6px}.editor-banner{background-color:var(--vscode-banner-background)}.editor-banner,.editor-banner .action-container .codicon,.editor-banner .message-actions-container .monaco-link{color:var(--vscode-banner-foreground)}.editor-banner .icon-container .codicon{color:var(--vscode-banner-iconForeground)}.monaco-link{color:var(--vscode-textLink-foreground)}.monaco-link:hover{color:var(--vscode-textLink-activeForeground)}.monaco-editor{--monaco-monospace-font:"SF Mono",Monaco,Menlo,Consolas,"Ubuntu Mono","Liberation Mono","DejaVu Sans Mono","Courier New",monospace;font-family:-apple-system,BlinkMacSystemFont,Segoe WPC,Segoe UI,HelveticaNeue-Light,system-ui,Ubuntu,Droid Sans,sans-serif}.monaco-editor.hc-black .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-editor.hc-light .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-editor.vs-dark .monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .action-label,.monaco-menu .monaco-action-bar.vertical .action-item .action-menu-item:focus .action-label{stroke-width:1.2px}.monaco-hover p{margin:0}.monaco-aria-container{clip:rect(1px,1px,1px,1px);clip-path:inset(50%);height:1px;margin:-1px;overflow:hidden;padding:0;position:absolute!important;top:0;width:1px}.monaco-diff-editor .synthetic-focus,.monaco-diff-editor [tabindex="-1"]:focus,.monaco-diff-editor [tabindex="0"]:focus,.monaco-diff-editor button:focus,.monaco-diff-editor input[type=button]:focus,.monaco-diff-editor input[type=checkbox]:focus,.monaco-diff-editor input[type=search]:focus,.monaco-diff-editor input[type=text]:focus,.monaco-diff-editor select:focus,.monaco-diff-editor textarea:focus,.monaco-editor{opacity:1;outline-color:var(--vscode-focusBorder);outline-offset:-1px;outline-style:solid;outline-width:1px}.monaco-workbench .workbench-hover{background:var(--vscode-editorHoverWidget-background);border:1px solid var(--vscode-editorHoverWidget-border);border-radius:3px;box-shadow:0 2px 8px var(--vscode-widget-shadow);color:var(--vscode-editorHoverWidget-foreground);font-size:13px;line-height:19px;max-width:700px;overflow:hidden;position:relative;z-index:40}.monaco-workbench .workbench-hover hr{border-bottom:none}.monaco-workbench .workbench-hover:not(.skip-fade-in){animation:fadein .1s linear}.monaco-workbench .workbench-hover.compact{font-size:12px}.monaco-workbench .workbench-hover.compact .hover-contents{padding:2px 8px}.monaco-workbench .workbench-hover-container.locked .workbench-hover{outline:1px solid var(--vscode-editorHoverWidget-border)}.monaco-workbench .workbench-hover-container.locked .workbench-hover:focus,.monaco-workbench .workbench-hover-lock:focus{outline:1px solid var(--vscode-focusBorder)}.monaco-workbench .workbench-hover-container.locked .workbench-hover-lock:hover{background:var(--vscode-toolbar-hoverBackground)}.monaco-workbench .workbench-hover-pointer{pointer-events:none;position:absolute;z-index:41}.monaco-workbench .workbench-hover-pointer:after{background-color:var(--vscode-editorHoverWidget-background);border-bottom:1px solid var(--vscode-editorHoverWidget-border);border-right:1px solid var(--vscode-editorHoverWidget-border);content:"";height:5px;position:absolute;width:5px}.monaco-workbench .locked .workbench-hover-pointer:after{border-bottom-width:2px;border-right-width:2px;height:4px;width:4px}.monaco-workbench .workbench-hover-pointer.left{left:-3px}.monaco-workbench .workbench-hover-pointer.right{right:3px}.monaco-workbench .workbench-hover-pointer.top{top:-3px}.monaco-workbench .workbench-hover-pointer.bottom{bottom:3px}.monaco-workbench .workbench-hover-pointer.left:after{transform:rotate(135deg)}.monaco-workbench .workbench-hover-pointer.right:after{transform:rotate(315deg)}.monaco-workbench .workbench-hover-pointer.top:after{transform:rotate(225deg)}.monaco-workbench .workbench-hover-pointer.bottom:after{transform:rotate(45deg)}.monaco-workbench .workbench-hover a{color:var(--vscode-textLink-foreground)}.monaco-workbench .workbench-hover a:focus{outline:1px solid;outline-color:var(--vscode-focusBorder);outline-offset:-1px;text-decoration:underline}.monaco-workbench .workbench-hover a:active,.monaco-workbench .workbench-hover a:hover{color:var(--vscode-textLink-activeForeground)}.monaco-workbench .workbench-hover code{background:var(--vscode-textCodeBlock-background)}.monaco-workbench .workbench-hover .hover-row .actions{background:var(--vscode-editorHoverWidget-statusBarBackground)}.monaco-workbench .workbench-hover.right-aligned{left:1px}.monaco-workbench .workbench-hover.right-aligned .hover-row.status-bar .actions{flex-direction:row-reverse}.monaco-workbench .workbench-hover.right-aligned .hover-row.status-bar .actions .action-container{margin-left:16px;margin-right:0}.context-view{position:absolute}.context-view.fixed{all:initial;color:inherit;font-family:inherit;font-size:13px;position:fixed}.quick-input-widget{font-size:13px}.quick-input-widget .monaco-highlighted-label .highlight{color:#0066bf}.vs .quick-input-widget .monaco-list-row.focused .monaco-highlighted-label .highlight{color:#9dddff}.vs-dark .quick-input-widget .monaco-highlighted-label .highlight{color:#0097fb}.hc-black .quick-input-widget .monaco-highlighted-label .highlight{color:#f38518}.hc-light .quick-input-widget .monaco-highlighted-label .highlight{color:#0f4a85}.monaco-keybinding>.monaco-keybinding-key{background-color:#ddd6;border:1px solid;border-color:#ccc6 #ccc6 #bbb6;box-shadow:inset 0 -1px 0 #bbb6;color:#555}.hc-black .monaco-keybinding>.monaco-keybinding-key{background-color:initial;border:1px solid #6fc3df;box-shadow:none;color:#fff}.hc-light .monaco-keybinding>.monaco-keybinding-key{background-color:initial;border:1px solid #0f4a85;box-shadow:none;color:#292929}.vs-dark .monaco-keybinding>.monaco-keybinding-key{background-color:#8080802b;border:1px solid;border-color:#3339 #3339 #4449;box-shadow:inset 0 -1px 0 #4449;color:#ccc}.quick-input-widget{-webkit-app-region:no-drag;border-radius:6px;left:50%;margin-left:-300px;position:absolute;width:600px;z-index:2550}.quick-input-titlebar{align-items:center;border-top-left-radius:5px;border-top-right-radius:5px;display:flex}.quick-input-left-action-bar{display:flex;flex:1 1;margin-left:4px}.quick-input-inline-action-bar{margin:2px 0 0 5px}.quick-input-title{overflow:hidden;padding:3px 0;text-align:center;text-overflow:ellipsis}.quick-input-right-action-bar{display:flex;flex:1 1;margin-right:4px}.quick-input-right-action-bar>.actions-container{justify-content:flex-end}.quick-input-titlebar .monaco-action-bar .action-label.codicon{background-position:50%;background-repeat:no-repeat;padding:2px}.quick-input-description{margin:6px 6px 6px 11px}.quick-input-header .quick-input-description{flex:1 1;margin:4px 2px}.quick-input-header{display:flex;padding:8px 6px 2px}.quick-input-widget.hidden-input .quick-input-header{margin-bottom:0;padding:0}.quick-input-and-message{display:flex;flex-direction:column;flex-grow:1;min-width:0;position:relative}.quick-input-check-all{align-self:center;margin:0}.quick-input-filter{display:flex;flex-grow:1;position:relative}.quick-input-box{flex-grow:1}.quick-input-widget.show-checkboxes .quick-input-box,.quick-input-widget.show-checkboxes .quick-input-message{margin-left:5px}.quick-input-visible-count{left:-10000px;position:absolute}.quick-input-count{align-items:center;align-self:center;display:flex;position:absolute;right:4px}.quick-input-count .monaco-count-badge{border-radius:2px;line-height:normal;min-height:auto;padding:2px 4px;vertical-align:middle}.quick-input-action{margin-left:6px}.quick-input-action .monaco-text-button{align-items:center;display:flex;font-size:11px;height:25px;padding:0 6px}.quick-input-message{margin-top:-1px;overflow-wrap:break-word;padding:5px}.quick-input-message>.codicon{margin:0 .2em;vertical-align:text-bottom}.quick-input-message a{color:inherit}.quick-input-progress.monaco-progress-container{position:relative}.quick-input-list{line-height:22px}.quick-input-widget.hidden-input .quick-input-list{margin-top:4px;padding-bottom:4px}.quick-input-list .monaco-list{max-height:440px;overflow:hidden;padding-bottom:5px}.quick-input-list .monaco-scrollable-element{padding:0 5px}.quick-input-list .quick-input-list-entry{box-sizing:border-box;display:flex;overflow:hidden;padding:0 6px}.quick-input-list .quick-input-list-entry.quick-input-list-separator-border{border-top-style:solid;border-top-width:1px}.quick-input-list .monaco-list-row{border-radius:3px}.quick-input-list .monaco-list-row[data-index="0"] .quick-input-list-entry.quick-input-list-separator-border{border-top-style:none}.quick-input-list .quick-input-list-label{display:flex;flex:1 1;height:100%;overflow:hidden}.quick-input-list .quick-input-list-checkbox{align-self:center;margin:0}.quick-input-list .quick-input-list-icon{align-items:center;background-position:0;background-repeat:no-repeat;background-size:16px;display:flex;height:22px;justify-content:center;padding-right:6px;width:16px}.quick-input-list .quick-input-list-rows{display:flex;flex:1 1;flex-direction:column;height:100%;margin-left:5px;overflow:hidden;text-overflow:ellipsis}.quick-input-widget.show-checkboxes .quick-input-list .quick-input-list-rows{margin-left:10px}.quick-input-widget .quick-input-list .quick-input-list-checkbox{display:none}.quick-input-widget.show-checkboxes .quick-input-list .quick-input-list-checkbox{display:inline}.quick-input-list .quick-input-list-rows>.quick-input-list-row{align-items:center;display:flex}.quick-input-list .quick-input-list-rows>.quick-input-list-row .monaco-icon-label,.quick-input-list .quick-input-list-rows>.quick-input-list-row .monaco-icon-label .monaco-icon-label-container>.monaco-icon-name-container{flex:1 1}.quick-input-list .quick-input-list-rows>.quick-input-list-row .codicon[class*=codicon-]{vertical-align:text-bottom}.quick-input-list .quick-input-list-rows .monaco-highlighted-label>span{opacity:1}.quick-input-list .quick-input-list-entry .quick-input-list-entry-keybinding{margin-right:8px}.quick-input-list .quick-input-list-label-meta{line-height:normal;opacity:.7;overflow:hidden;text-overflow:ellipsis}.quick-input-list .monaco-list .monaco-list-row .monaco-highlighted-label .highlight{background-color:unset;color:var(--vscode-list-highlightForeground)!important;font-weight:700}.quick-input-list .monaco-list .monaco-list-row.focused .monaco-highlighted-label .highlight{color:var(--vscode-list-focusHighlightForeground)!important}.quick-input-list .quick-input-list-entry .quick-input-list-separator{margin-right:4px}.quick-input-list .quick-input-list-entry-action-bar{display:flex;flex:0 1;overflow:visible}.quick-input-list .quick-input-list-entry-action-bar .action-label{display:none}.quick-input-list .quick-input-list-entry-action-bar .action-label.codicon{margin-right:4px;padding:2px}.quick-input-list .quick-input-list-entry-action-bar{margin-right:4px;margin-top:1px}.quick-input-list .monaco-list-row.focused .quick-input-list-entry-action-bar .action-label,.quick-input-list .monaco-list-row.passive-focused .quick-input-list-entry-action-bar .action-label,.quick-input-list .quick-input-list-entry .quick-input-list-entry-action-bar .action-label.always-visible,.quick-input-list .quick-input-list-entry.focus-inside .quick-input-list-entry-action-bar .action-label,.quick-input-list .quick-input-list-entry:hover .quick-input-list-entry-action-bar .action-label{display:flex}.quick-input-list .monaco-list-row.focused .monaco-keybinding-key,.quick-input-list .monaco-list-row.focused .quick-input-list-entry .quick-input-list-separator{color:inherit}.quick-input-list .monaco-list-row.focused .monaco-keybinding-key{background:none}.quick-input-list .quick-input-list-separator-as-item{font-size:12px;padding:4px 6px}.quick-input-list .quick-input-list-separator-as-item .label-name{font-weight:600}.quick-input-list .quick-input-list-separator-as-item .label-description{opacity:1!important}.quick-input-list .monaco-tree-sticky-row .quick-input-list-entry.quick-input-list-separator-as-item.quick-input-list-separator-border{border-top-style:none}.quick-input-list .monaco-tree-sticky-row{padding:0 5px}.quick-input-list .monaco-tl-twistie{display:none!important}.monaco-progress-container{height:2px;overflow:hidden;width:100%}.monaco-progress-container .progress-bit{display:none;height:2px;left:0;position:absolute;width:2%}.monaco-progress-container.active .progress-bit{display:inherit}.monaco-progress-container.discrete .progress-bit{left:0;transition:width .1s linear}.monaco-progress-container.discrete.done .progress-bit{width:100%}.monaco-progress-container.infinite .progress-bit{animation-duration:4s;animation-iteration-count:infinite;animation-name:progress;animation-timing-function:linear;transform:translateZ(0)}.monaco-progress-container.infinite.infinite-long-running .progress-bit{animation-timing-function:steps(100)}@keyframes progress{0%{transform:translateX(0) scaleX(1)}50%{transform:translateX(2500%) scaleX(3)}to{transform:translateX(4900%) scaleX(1)}}.monaco-component.multiDiffEditor{background:var(--vscode-multiDiffEditor-background);height:100%;overflow-y:hidden;position:relative;width:100%;>div{height:100%;left:0;position:absolute;top:0;width:100%;&.placeholder{display:grid;place-content:center;place-items:center;visibility:hidden;&.visible{visibility:visible}}}.active{--vscode-multiDiffEditor-border:var(--vscode-focusBorder)}.multiDiffEntry{display:flex;flex:1 1;flex-direction:column;overflow:hidden;.collapse-button{cursor:pointer;margin:0 5px;a{display:block}}.header{background:var(--vscode-editor-background);z-index:1000;&:not(.collapsed) .header-content{border-bottom:1px solid var(--vscode-sideBarSectionHeader-border)}.header-content{align-items:center;background:var(--vscode-multiDiffEditor-headerBackground);border-top:1px solid var(--vscode-multiDiffEditor-border);color:var(--vscode-foreground);display:flex;margin:8px 0 0;padding:4px 5px;&.shadow{box-shadow:var(--vscode-scrollbar-shadow) 0 6px 6px -6px}.file-path{display:flex;flex:1 1;min-width:0;.title{font-size:14px;line-height:22px;&.original{flex:1 1;min-width:0;text-overflow:ellipsis}}.status{font-weight:600;line-height:22px;margin:0 10px;opacity:.75}}.actions{padding:0 8px}}}.editorParent{border-bottom:1px solid var(--vscode-multiDiffEditor-border);display:flex;flex:1 1;flex-direction:column;overflow:hidden}.editorContainer{flex:1 1}}}.gt-table{border:none;border-collapse:initial;border-spacing:0}.gt-table__row_interactive{cursor:pointer}.gt-table__header_sticky{inset-block-start:0;position:sticky;z-index:1}.gt-table__footer_sticky{inset-block-end:0;position:sticky;z-index:1}.gt-table__cell{font-weight:400}.gt-table__footer-cell,.gt-table__header-cell{font-weight:500;position:relative}.gt-table__cell,.gt-table__footer-cell,.gt-table__header-cell{box-sizing:border-box;height:inherit;padding:0;text-align:start}.gt-table__cell_pinned,.gt-table__footer-cell_pinned,.gt-table__header-cell_pinned{position:sticky;z-index:1}.gt-table__sort{cursor:pointer;-webkit-user-select:none;user-select:none}.gt-table_with-row-virtualization{display:grid;height:auto}.gt-table_with-row-virtualization .gt-table__body{display:grid;position:relative}.gt-table_with-row-virtualization .gt-table__footer,.gt-table_with-row-virtualization .gt-table__header{display:grid}.gt-table_with-row-virtualization .gt-table__footer-row,.gt-table_with-row-virtualization .gt-table__header-row{display:flex;height:auto}.gt-table_with-row-virtualization .gt-table__row{display:flex;height:auto;position:absolute}.gt-table_with-row-virtualization .gt-table__row_empty{position:relative}.gt-group-header{inset-inline-start:0;margin:0;position:sticky}.gt-group-header__button{appearance:none;background:inherit;border:none;cursor:pointer;display:flex;gap:8px;outline:none;padding:0;width:100%}.gt-group-header__icon{display:inline-block;transform:rotate(-90deg);transition:transform .1s ease-out;vertical-align:middle}.gt-group-header__icon_expanded{transform:rotate(0)}.gt-group-header__content{display:inline-flex;font-weight:500;gap:4px}.gt-sort-indicator{color:var(--g-color-text-hint);display:inline-flex;margin-inline-start:4px;transform:rotate(0);vertical-align:middle}.gt-sort-indicator_invisible{opacity:0}.gt-table__header-cell:hover .gt-sort-indicator_invisible{opacity:1}.gt-sort-indicator_order_asc{transform:rotate(180deg)}.gt-resize-handle{background:#d3d3d3;cursor:col-resize;height:100%;inset-block-start:0;opacity:0;position:absolute;touch-action:none;-webkit-user-select:none;user-select:none;width:6px}.gt-resize-handle_direction_ltr{inset-inline-end:0}.gt-resize-handle_direction_rtl{inset-inline-start:0}.gt-resize-handle_resizing,.gt-table__header-cell:hover .gt-resize-handle{opacity:1}.ydb-navigation-tree-view-empty{color:var(--g-color-text-secondary);font-style:italic}.ydb-navigation-tree-view-error{color:var(--g-color-text-danger)}.ydb-navigation-tree-view-loader{align-items:center;display:flex;height:24px;justify-content:center;width:20px} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/main.88491618.css b/ydb/core/viewer/monitoring/static/css/main.88491618.css new file mode 100644 index 000000000000..3c1abde15292 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/css/main.88491618.css @@ -0,0 +1,9 @@ +@charset "UTF-8";@import url(https://fonts.googleapis.com/css2?family=Rubik&display=swap);:root{--data-table-header-vertical-padding:5px;--data-table-cell-vertical-padding:5px;--data-table-cell-horizontal-padding:10px;--data-table-cell-border-padding:var(--data-table-cell-horizontal-padding);--data-table-cell-align:top;--data-table-head-align:top;--data-table-row-height:30px;--data-table-sort-icon-space:18px;--data-table-sort-icon-opacity-inactive:0.15;--data-table-sort-icon-color:inherit}.data-table{box-sizing:border-box;position:relative}.data-table__box{box-sizing:border-box;height:100%;width:100%}.data-table__box_sticky-head_moving{overflow:visible;position:relative;z-index:0}.data-table__box_sticky-head_moving .data-table__th{border-bottom:0;border-top:0;padding-bottom:0;padding-top:0}.data-table__box_sticky-head_moving .data-table__head-cell{display:block;height:0;overflow:hidden}.data-table__box_sticky-head_moving .data-table__row_header-data{visibility:hidden}.data-table__box_sticky-footer_fixed,.data-table__box_sticky-head_fixed{overflow:auto}.data-table__table{border-collapse:collapse;table-layout:fixed}.data-table__table_sticky{background:var(--data-table-color-base);width:100%}.data-table__row{height:var(--data-table-row-height)}.data-table__th{border:1px solid var(--data-table-border-color);box-sizing:border-box;cursor:default;font-weight:500;padding:var(--data-table-header-vertical-padding) var(--data-table-cell-horizontal-padding);position:relative;text-align:left;vertical-align:var(--data-table-head-align)}.data-table__th_sortable{cursor:pointer}.data-table__th_sortable .data-table__head-cell{padding-right:var(--data-table-sort-icon-space)}.data-table__th_sortable.data-table__th_align_right .data-table__head-cell{padding-left:var(--data-table-sort-icon-space);padding-right:0}.data-table__th_sortable.data-table__th_align_right .data-table__sort-icon{left:0;right:auto;transform:translateY(-50%) scaleX(-1)}.data-table__td{border:1px solid var(--data-table-border-color);box-sizing:border-box;overflow:hidden;padding:var(--data-table-cell-vertical-padding) var(--data-table-cell-horizontal-padding);text-overflow:ellipsis;vertical-align:var(--data-table-cell-align);white-space:nowrap}.data-table__td_index,.data-table__th_index{text-align:right}.data-table__td_align_left,.data-table__th_align_left{text-align:left}.data-table__td_align_center,.data-table__th_align_center{text-align:center}.data-table__td_align_right,.data-table__th_align_right{text-align:right}.data-table__td:first-child,.data-table__th:first-child{padding-left:var(--data-table-cell-border-padding)}.data-table__td:last-child,.data-table__th:last-child{padding-right:var(--data-table-cell-border-padding)}.data-table__index{text-align:right}.data-table__head-cell{box-sizing:border-box;display:inline-block;max-width:100%;overflow:hidden;position:relative;text-overflow:ellipsis;vertical-align:top;white-space:nowrap}.data-table__error{padding:20px;white-space:pre-wrap}.data-table__sort-icon{color:var(--data-table-sort-icon-color);display:inline-flex;position:absolute;right:0;top:50%;transform:translateY(-50%)}.data-table__sort-icon:after{content:attr(data-index);font-size:8px;left:100%;position:absolute;top:-5px}.data-table__sort-icon_shadow{opacity:var(--data-table-sort-icon-opacity-inactive)}.data-table__sort-icon_shadow:after{content:none}.data-table__icon{vertical-align:top}.data-table__no-data{background:var(--data-table-color-stripe)}.data-table__sticky_fixed{left:0;overflow:hidden;position:absolute;right:0;z-index:1}.data-table__sticky_fixed.data-table__sticky_head{top:0}.data-table__sticky_fixed.data-table__sticky_footer{bottom:0}.data-table__sticky_moving{margin-bottom:-1px;position:sticky;z-index:1}.data-table_striped-rows .data-table__row_odd{background:var(--data-table-color-stripe)}.data-table_highlight-rows .data-table__row:hover{background:var(--data-table-color-hover-area)}.data-table_header_multiline .data-table__head-cell{white-space:normal}.data-table_header_pre .data-table__head-cell{white-space:pre}.data-table__foot{background:var(--data-table-color-footer-area)}.data-table__foot_has-sticky-footer_moving{visibility:hidden}.data-table_theme_yandex-cloud{--data-table-color-base:var(--g-color-base-background,var(--yc-color-base-background));--data-table-color-stripe:var( --g-color-base-generic-ultralight,var(--yc-color-base-generic-ultralight) );--data-table-border-color:var( --g-color-base-generic-hover,var(--yc-color-base-generic-hover) );--data-table-color-hover-area:var( --g-color-base-simple-hover,var(--yc-color-base-simple-hover) );--data-table-color-footer-area:var(--data-table-color-base)}.data-table_theme_legacy{--data-table-color-base:#fff;--data-table-color-stripe:#00000008;--data-table-border-color:#ddd;--data-table-color-hover-area:#ffeba0;--data-table-color-footer-area:var(--data-table-color-base)}.data-table__resize-handler{background-color:var(--g-color-base-generic);cursor:col-resize;height:100%;position:absolute;right:0;top:0;visibility:hidden;width:6px}.data-table__resize-handler_resizing,.data-table__th:hover>.data-table__resize-handler{visibility:visible}.ydb-error-boundary{--g-definition-list-item-gap:var(--g-spacing-1);padding:var(--g-spacing-8)}.ydb-error-boundary__error-stack-wrapper{background-color:var(--code-background-color);border-radius:var(--g-border-radius-xs);height:430px;overflow:auto;scrollbar-color:var(--g-color-scroll-handle) #0000;width:800px}.ydb-error-boundary__error-stack-title{border-bottom:1px solid var(--g-color-line-generic);left:0;padding:var(--g-spacing-2) var(--g-spacing-3);position:sticky}.ydb-error-boundary__error-stack-code{padding:var(--g-spacing-3) var(--g-spacing-3) var(--g-spacing-2);white-space:pre-wrap}.ydb-error-boundary__qr-help-text{text-align:right}.g-s__m_0{margin:var(--g-spacing-0)}.g-s__mr_0{margin-inline-end:var(--g-spacing-0)}.g-s__ml_0{margin-inline-start:var(--g-spacing-0)}.g-s__mt_0{margin-block-start:var(--g-spacing-0)}.g-s__mb_0{margin-block-end:var(--g-spacing-0)}.g-s__mx_0{margin-inline:var(--g-spacing-0)}.g-s__my_0{margin-block:var(--g-spacing-0)}.g-s__p_0{padding:var(--g-spacing-0)}.g-s__pl_0{padding-inline-start:var(--g-spacing-0)}.g-s__pr_0{padding-inline-end:var(--g-spacing-0)}.g-s__pb_0{padding-block-end:var(--g-spacing-0)}.g-s__pt_0{padding-block-start:var(--g-spacing-0)}.g-s__py_0{padding-block:var(--g-spacing-0)}.g-s__px_0{padding-inline:var(--g-spacing-0)}.g-s__m_half{margin:var(--g-spacing-half)}.g-s__mr_half{margin-inline-end:var(--g-spacing-half)}.g-s__ml_half{margin-inline-start:var(--g-spacing-half)}.g-s__mt_half{margin-block-start:var(--g-spacing-half)}.g-s__mb_half{margin-block-end:var(--g-spacing-half)}.g-s__mx_half{margin-inline:var(--g-spacing-half)}.g-s__my_half{margin-block:var(--g-spacing-half)}.g-s__p_half{padding:var(--g-spacing-half)}.g-s__pl_half{padding-inline-start:var(--g-spacing-half)}.g-s__pr_half{padding-inline-end:var(--g-spacing-half)}.g-s__pb_half{padding-block-end:var(--g-spacing-half)}.g-s__pt_half{padding-block-start:var(--g-spacing-half)}.g-s__py_half{padding-block:var(--g-spacing-half)}.g-s__px_half{padding-inline:var(--g-spacing-half)}.g-s__m_1{margin:var(--g-spacing-1)}.g-s__mr_1{margin-inline-end:var(--g-spacing-1)}.g-s__ml_1{margin-inline-start:var(--g-spacing-1)}.g-s__mt_1{margin-block-start:var(--g-spacing-1)}.g-s__mb_1{margin-block-end:var(--g-spacing-1)}.g-s__mx_1{margin-inline:var(--g-spacing-1)}.g-s__my_1{margin-block:var(--g-spacing-1)}.g-s__p_1{padding:var(--g-spacing-1)}.g-s__pl_1{padding-inline-start:var(--g-spacing-1)}.g-s__pr_1{padding-inline-end:var(--g-spacing-1)}.g-s__pb_1{padding-block-end:var(--g-spacing-1)}.g-s__pt_1{padding-block-start:var(--g-spacing-1)}.g-s__py_1{padding-block:var(--g-spacing-1)}.g-s__px_1{padding-inline:var(--g-spacing-1)}.g-s__m_2{margin:var(--g-spacing-2)}.g-s__mr_2{margin-inline-end:var(--g-spacing-2)}.g-s__ml_2{margin-inline-start:var(--g-spacing-2)}.g-s__mt_2{margin-block-start:var(--g-spacing-2)}.g-s__mb_2{margin-block-end:var(--g-spacing-2)}.g-s__mx_2{margin-inline:var(--g-spacing-2)}.g-s__my_2{margin-block:var(--g-spacing-2)}.g-s__p_2{padding:var(--g-spacing-2)}.g-s__pl_2{padding-inline-start:var(--g-spacing-2)}.g-s__pr_2{padding-inline-end:var(--g-spacing-2)}.g-s__pb_2{padding-block-end:var(--g-spacing-2)}.g-s__pt_2{padding-block-start:var(--g-spacing-2)}.g-s__py_2{padding-block:var(--g-spacing-2)}.g-s__px_2{padding-inline:var(--g-spacing-2)}.g-s__m_3{margin:var(--g-spacing-3)}.g-s__mr_3{margin-inline-end:var(--g-spacing-3)}.g-s__ml_3{margin-inline-start:var(--g-spacing-3)}.g-s__mt_3{margin-block-start:var(--g-spacing-3)}.g-s__mb_3{margin-block-end:var(--g-spacing-3)}.g-s__mx_3{margin-inline:var(--g-spacing-3)}.g-s__my_3{margin-block:var(--g-spacing-3)}.g-s__p_3{padding:var(--g-spacing-3)}.g-s__pl_3{padding-inline-start:var(--g-spacing-3)}.g-s__pr_3{padding-inline-end:var(--g-spacing-3)}.g-s__pb_3{padding-block-end:var(--g-spacing-3)}.g-s__pt_3{padding-block-start:var(--g-spacing-3)}.g-s__py_3{padding-block:var(--g-spacing-3)}.g-s__px_3{padding-inline:var(--g-spacing-3)}.g-s__m_4{margin:var(--g-spacing-4)}.g-s__mr_4{margin-inline-end:var(--g-spacing-4)}.g-s__ml_4{margin-inline-start:var(--g-spacing-4)}.g-s__mt_4{margin-block-start:var(--g-spacing-4)}.g-s__mb_4{margin-block-end:var(--g-spacing-4)}.g-s__mx_4{margin-inline:var(--g-spacing-4)}.g-s__my_4{margin-block:var(--g-spacing-4)}.g-s__p_4{padding:var(--g-spacing-4)}.g-s__pl_4{padding-inline-start:var(--g-spacing-4)}.g-s__pr_4{padding-inline-end:var(--g-spacing-4)}.g-s__pb_4{padding-block-end:var(--g-spacing-4)}.g-s__pt_4{padding-block-start:var(--g-spacing-4)}.g-s__py_4{padding-block:var(--g-spacing-4)}.g-s__px_4{padding-inline:var(--g-spacing-4)}.g-s__m_5{margin:var(--g-spacing-5)}.g-s__mr_5{margin-inline-end:var(--g-spacing-5)}.g-s__ml_5{margin-inline-start:var(--g-spacing-5)}.g-s__mt_5{margin-block-start:var(--g-spacing-5)}.g-s__mb_5{margin-block-end:var(--g-spacing-5)}.g-s__mx_5{margin-inline:var(--g-spacing-5)}.g-s__my_5{margin-block:var(--g-spacing-5)}.g-s__p_5{padding:var(--g-spacing-5)}.g-s__pl_5{padding-inline-start:var(--g-spacing-5)}.g-s__pr_5{padding-inline-end:var(--g-spacing-5)}.g-s__pb_5{padding-block-end:var(--g-spacing-5)}.g-s__pt_5{padding-block-start:var(--g-spacing-5)}.g-s__py_5{padding-block:var(--g-spacing-5)}.g-s__px_5{padding-inline:var(--g-spacing-5)}.g-s__m_6{margin:var(--g-spacing-6)}.g-s__mr_6{margin-inline-end:var(--g-spacing-6)}.g-s__ml_6{margin-inline-start:var(--g-spacing-6)}.g-s__mt_6{margin-block-start:var(--g-spacing-6)}.g-s__mb_6{margin-block-end:var(--g-spacing-6)}.g-s__mx_6{margin-inline:var(--g-spacing-6)}.g-s__my_6{margin-block:var(--g-spacing-6)}.g-s__p_6{padding:var(--g-spacing-6)}.g-s__pl_6{padding-inline-start:var(--g-spacing-6)}.g-s__pr_6{padding-inline-end:var(--g-spacing-6)}.g-s__pb_6{padding-block-end:var(--g-spacing-6)}.g-s__pt_6{padding-block-start:var(--g-spacing-6)}.g-s__py_6{padding-block:var(--g-spacing-6)}.g-s__px_6{padding-inline:var(--g-spacing-6)}.g-s__m_7{margin:var(--g-spacing-7)}.g-s__mr_7{margin-inline-end:var(--g-spacing-7)}.g-s__ml_7{margin-inline-start:var(--g-spacing-7)}.g-s__mt_7{margin-block-start:var(--g-spacing-7)}.g-s__mb_7{margin-block-end:var(--g-spacing-7)}.g-s__mx_7{margin-inline:var(--g-spacing-7)}.g-s__my_7{margin-block:var(--g-spacing-7)}.g-s__p_7{padding:var(--g-spacing-7)}.g-s__pl_7{padding-inline-start:var(--g-spacing-7)}.g-s__pr_7{padding-inline-end:var(--g-spacing-7)}.g-s__pb_7{padding-block-end:var(--g-spacing-7)}.g-s__pt_7{padding-block-start:var(--g-spacing-7)}.g-s__py_7{padding-block:var(--g-spacing-7)}.g-s__px_7{padding-inline:var(--g-spacing-7)}.g-s__m_8{margin:var(--g-spacing-8)}.g-s__mr_8{margin-inline-end:var(--g-spacing-8)}.g-s__ml_8{margin-inline-start:var(--g-spacing-8)}.g-s__mt_8{margin-block-start:var(--g-spacing-8)}.g-s__mb_8{margin-block-end:var(--g-spacing-8)}.g-s__mx_8{margin-inline:var(--g-spacing-8)}.g-s__my_8{margin-block:var(--g-spacing-8)}.g-s__p_8{padding:var(--g-spacing-8)}.g-s__pl_8{padding-inline-start:var(--g-spacing-8)}.g-s__pr_8{padding-inline-end:var(--g-spacing-8)}.g-s__pb_8{padding-block-end:var(--g-spacing-8)}.g-s__pt_8{padding-block-start:var(--g-spacing-8)}.g-s__py_8{padding-block:var(--g-spacing-8)}.g-s__px_8{padding-inline:var(--g-spacing-8)}.g-s__m_9{margin:var(--g-spacing-9)}.g-s__mr_9{margin-inline-end:var(--g-spacing-9)}.g-s__ml_9{margin-inline-start:var(--g-spacing-9)}.g-s__mt_9{margin-block-start:var(--g-spacing-9)}.g-s__mb_9{margin-block-end:var(--g-spacing-9)}.g-s__mx_9{margin-inline:var(--g-spacing-9)}.g-s__my_9{margin-block:var(--g-spacing-9)}.g-s__p_9{padding:var(--g-spacing-9)}.g-s__pl_9{padding-inline-start:var(--g-spacing-9)}.g-s__pr_9{padding-inline-end:var(--g-spacing-9)}.g-s__pb_9{padding-block-end:var(--g-spacing-9)}.g-s__pt_9{padding-block-start:var(--g-spacing-9)}.g-s__py_9{padding-block:var(--g-spacing-9)}.g-s__px_9{padding-inline:var(--g-spacing-9)}.g-s__m_10{margin:var(--g-spacing-10)}.g-s__mr_10{margin-inline-end:var(--g-spacing-10)}.g-s__ml_10{margin-inline-start:var(--g-spacing-10)}.g-s__mt_10{margin-block-start:var(--g-spacing-10)}.g-s__mb_10{margin-block-end:var(--g-spacing-10)}.g-s__mx_10{margin-inline:var(--g-spacing-10)}.g-s__my_10{margin-block:var(--g-spacing-10)}.g-s__p_10{padding:var(--g-spacing-10)}.g-s__pl_10{padding-inline-start:var(--g-spacing-10)}.g-s__pr_10{padding-inline-end:var(--g-spacing-10)}.g-s__pb_10{padding-block-end:var(--g-spacing-10)}.g-s__pt_10{padding-block-start:var(--g-spacing-10)}.g-s__py_10{padding-block:var(--g-spacing-10)}.g-s__px_10{padding-inline:var(--g-spacing-10)}.g-box{box-sizing:border-box}.g-box_overflow_hidden{overflow:hidden}.g-box_overflow_auto{overflow:auto}.g-box_overflow_x{overflow:hidden auto}.g-box_overflow_y{overflow:auto hidden}.g-flex{display:flex}.g-flex_inline{display:inline-flex}.g-flex_center-content{align-items:center;justify-content:center}.g-flex_s_0{margin-block-start:calc(var(--g-spacing-0)*-1)!important;margin-inline-start:calc(var(--g-spacing-0)*-1)!important}.g-flex_s_0>*{padding-block-start:var(--g-spacing-0)!important;padding-inline-start:var(--g-spacing-0)!important}.g-flex_s_half{margin-block-start:calc(var(--g-spacing-half)*-1)!important;margin-inline-start:calc(var(--g-spacing-half)*-1)!important}.g-flex_s_half>*{padding-block-start:var(--g-spacing-half)!important;padding-inline-start:var(--g-spacing-half)!important}.g-flex_s_1{margin-block-start:calc(var(--g-spacing-1)*-1)!important;margin-inline-start:calc(var(--g-spacing-1)*-1)!important}.g-flex_s_1>*{padding-block-start:var(--g-spacing-1)!important;padding-inline-start:var(--g-spacing-1)!important}.g-flex_s_2{margin-block-start:calc(var(--g-spacing-2)*-1)!important;margin-inline-start:calc(var(--g-spacing-2)*-1)!important}.g-flex_s_2>*{padding-block-start:var(--g-spacing-2)!important;padding-inline-start:var(--g-spacing-2)!important}.g-flex_s_3{margin-block-start:calc(var(--g-spacing-3)*-1)!important;margin-inline-start:calc(var(--g-spacing-3)*-1)!important}.g-flex_s_3>*{padding-block-start:var(--g-spacing-3)!important;padding-inline-start:var(--g-spacing-3)!important}.g-flex_s_4{margin-block-start:calc(var(--g-spacing-4)*-1)!important;margin-inline-start:calc(var(--g-spacing-4)*-1)!important}.g-flex_s_4>*{padding-block-start:var(--g-spacing-4)!important;padding-inline-start:var(--g-spacing-4)!important}.g-flex_s_5{margin-block-start:calc(var(--g-spacing-5)*-1)!important;margin-inline-start:calc(var(--g-spacing-5)*-1)!important}.g-flex_s_5>*{padding-block-start:var(--g-spacing-5)!important;padding-inline-start:var(--g-spacing-5)!important}.g-flex_s_6{margin-block-start:calc(var(--g-spacing-6)*-1)!important;margin-inline-start:calc(var(--g-spacing-6)*-1)!important}.g-flex_s_6>*{padding-block-start:var(--g-spacing-6)!important;padding-inline-start:var(--g-spacing-6)!important}.g-flex_s_7{margin-block-start:calc(var(--g-spacing-7)*-1)!important;margin-inline-start:calc(var(--g-spacing-7)*-1)!important}.g-flex_s_7>*{padding-block-start:var(--g-spacing-7)!important;padding-inline-start:var(--g-spacing-7)!important}.g-flex_s_8{margin-block-start:calc(var(--g-spacing-8)*-1)!important;margin-inline-start:calc(var(--g-spacing-8)*-1)!important}.g-flex_s_8>*{padding-block-start:var(--g-spacing-8)!important;padding-inline-start:var(--g-spacing-8)!important}.g-flex_s_9{margin-block-start:calc(var(--g-spacing-9)*-1)!important;margin-inline-start:calc(var(--g-spacing-9)*-1)!important}.g-flex_s_9>*{padding-block-start:var(--g-spacing-9)!important;padding-inline-start:var(--g-spacing-9)!important}.g-flex_s_10{margin-block-start:calc(var(--g-spacing-10)*-1)!important;margin-inline-start:calc(var(--g-spacing-10)*-1)!important}.g-flex_s_10>*{padding-block-start:var(--g-spacing-10)!important;padding-inline-start:var(--g-spacing-10)!important}.g-color-text_color_primary{color:var(--g-color-text-primary)}.g-color-text_color_complementary{color:var(--g-color-text-complementary)}.g-color-text_color_secondary{color:var(--g-color-text-secondary)}.g-color-text_color_hint{color:var(--g-color-text-hint)}.g-color-text_color_info{color:var(--g-color-text-info)}.g-color-text_color_info-heavy{color:var(--g-color-text-info-heavy)}.g-color-text_color_positive{color:var(--g-color-text-positive)}.g-color-text_color_positive-heavy{color:var(--g-color-text-positive-heavy)}.g-color-text_color_warning{color:var(--g-color-text-warning)}.g-color-text_color_warning-heavy{color:var(--g-color-text-warning-heavy)}.g-color-text_color_danger{color:var(--g-color-text-danger)}.g-color-text_color_danger-heavy{color:var(--g-color-text-danger-heavy)}.g-color-text_color_utility{color:var(--g-color-text-utility)}.g-color-text_color_utility-heavy{color:var(--g-color-text-utility-heavy)}.g-color-text_color_misc{color:var(--g-color-text-misc)}.g-color-text_color_misc-heavy{color:var(--g-color-text-misc-heavy)}.g-color-text_color_brand{color:var(--g-color-text-brand)}.g-color-text_color_link{color:var(--g-color-text-link)}.g-color-text_color_link-hover{color:var(--g-color-text-link-hover)}.g-color-text_color_link-visited{color:var(--g-color-text-link-visited)}.g-color-text_color_link-visited-hover{color:var(--g-color-text-link-visited-hover)}.g-color-text_color_dark-primary{color:var(--g-color-text-dark-primary)}.g-color-text_color_dark-complementary{color:var(--g-color-text-dark-complementary)}.g-color-text_color_dark-secondary{color:var(--g-color-text-dark-secondary)}.g-color-text_color_light-primary{color:var(--g-color-text-light-primary)}.g-color-text_color_light-complementary{color:var(--g-color-text-light-complementary)}.g-color-text_color_light-secondary{color:var(--g-color-text-light-secondary)}.g-color-text_color_light-hint{color:var(--g-color-text-light-hint)}.g-color-text_color_inverted-primary{color:var(--g-color-text-inverted-primary)}.g-color-text_color_inverted-complementary{color:var(--g-color-text-inverted-complementary)}.g-color-text_color_inverted-secondary{color:var(--g-color-text-inverted-secondary)}.g-color-text_color_inverted-hint{color:var(--g-color-text-inverted-hint)}.g-text_variant_display-1{font-size:var(--g-text-display-1-font-size);line-height:var(--g-text-display-1-line-height)}.g-text_variant_display-1,.g-text_variant_display-2{font-family:var(--g-text-display-font-family);font-weight:var(--g-text-display-font-weight)}.g-text_variant_display-2{font-size:var(--g-text-display-2-font-size);line-height:var(--g-text-display-2-line-height)}.g-text_variant_display-3{font-size:var(--g-text-display-3-font-size);line-height:var(--g-text-display-3-line-height)}.g-text_variant_display-3,.g-text_variant_display-4{font-family:var(--g-text-display-font-family);font-weight:var(--g-text-display-font-weight)}.g-text_variant_display-4{font-size:var(--g-text-display-4-font-size);line-height:var(--g-text-display-4-line-height)}.g-text_variant_code-1{font-size:var(--g-text-code-1-font-size);line-height:var(--g-text-code-1-line-height)}.g-text_variant_code-1,.g-text_variant_code-2{font-family:var(--g-text-code-font-family);font-weight:var(--g-text-code-font-weight)}.g-text_variant_code-2{font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-code-2-line-height)}.g-text_variant_code-3{font-size:var(--g-text-code-3-font-size);line-height:var(--g-text-code-3-line-height)}.g-text_variant_code-3,.g-text_variant_code-inline-1{font-family:var(--g-text-code-font-family);font-weight:var(--g-text-code-font-weight)}.g-text_variant_code-inline-1{font-size:var(--g-text-code-inline-1-font-size);line-height:var(--g-text-code-inline-1-line-height)}.g-text_variant_code-inline-2{font-size:var(--g-text-code-inline-2-font-size);line-height:var(--g-text-code-inline-2-line-height)}.g-text_variant_code-inline-2,.g-text_variant_code-inline-3{font-family:var(--g-text-code-font-family);font-weight:var(--g-text-code-font-weight)}.g-text_variant_code-inline-3{font-size:var(--g-text-code-inline-3-font-size);line-height:var(--g-text-code-inline-3-line-height)}.g-text_variant_body-1{font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height)}.g-text_variant_body-1,.g-text_variant_body-2{font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight)}.g-text_variant_body-2{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.g-text_variant_body-3{font-size:var(--g-text-body-3-font-size);line-height:var(--g-text-body-3-line-height)}.g-text_variant_body-3,.g-text_variant_body-short{font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight)}.g-text_variant_body-short{font-size:var(--g-text-body-short-font-size);line-height:var(--g-text-body-short-line-height)}.g-text_variant_caption-1{font-size:var(--g-text-caption-1-font-size);line-height:var(--g-text-caption-1-line-height)}.g-text_variant_caption-1,.g-text_variant_caption-2{font-family:var(--g-text-caption-font-family);font-weight:var(--g-text-caption-font-weight)}.g-text_variant_caption-2{font-size:var(--g-text-caption-2-font-size);line-height:var(--g-text-caption-2-line-height)}.g-text_variant_header-1{font-size:var(--g-text-header-1-font-size);line-height:var(--g-text-header-1-line-height)}.g-text_variant_header-1,.g-text_variant_header-2{font-family:var(--g-text-header-font-family);font-weight:var(--g-text-header-font-weight)}.g-text_variant_header-2{font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.g-text_variant_subheader-1{font-size:var(--g-text-subheader-1-font-size);line-height:var(--g-text-subheader-1-line-height)}.g-text_variant_subheader-1,.g-text_variant_subheader-2{font-family:var(--g-text-subheader-font-family);font-weight:var(--g-text-subheader-font-weight)}.g-text_variant_subheader-2{font-size:var(--g-text-subheader-2-font-size);line-height:var(--g-text-subheader-2-line-height)}.g-text_variant_subheader-3{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-text_ellipsis{display:inline-block;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-text_ellipsis-lines{-webkit-box-orient:vertical;-webkit-line-clamp:2;align-self:center;display:-webkit-box;overflow:hidden;white-space:normal}.g-text_ws_nowrap{white-space:nowrap}.g-text_ws_break-spaces{white-space:break-spaces}.g-text_wb_break-all{word-break:break-all}.g-text_wb_break-word{word-break:break-word}.g-clipboard-button__icon{pointer-events:none}.g-icon{line-height:0;vertical-align:top}.g-button{--_--text-color:var(--g-color-text-primary);--_--text-color-hover:var(--_--text-color);--_--background-color:#0000;--_--background-color-hover:var(--g-color-base-simple-hover);--_--border-width:0;--_--border-color:currentColor;--_--focus-outline-color:var(--g-color-line-focus);--_--focus-outline-offset:0;--_--font-size:var(--g-text-body-1-font-size);-webkit-tap-highlight-color:rgba(0,0,0,0);background:none;background:#0000;border:none;box-sizing:border-box;color:inherit;color:var(--g-button-text-color,var(--_--text-color));cursor:pointer;display:inline-flex;font-family:var(--g-text-body-font-family);font-size:inherit;font-size:var(--g-button-font-size,var(--_--font-size));font-weight:var(--g-text-body-font-weight);gap:var(--g-button-icon-offset,var(--_--icon-offset));height:var(--g-button-height,var(--_--height));justify-content:center;line-height:var(--g-button-height,var(--_--height));outline:none;overflow:visible;padding:0;padding:0 var(--g-button-padding,var(--_--padding));position:relative;text-align:center;text-decoration:none;touch-action:manipulation;transform:scale(1);transition:transform .1s ease-out,color .15s linear;-webkit-user-select:none;user-select:none;white-space:nowrap}.g-button:before{background-color:var(--g-button-background-color,var(--_--background-color));border:var(--g-button-border-width,var(--_--border-width)) var(--g-button-border-style,solid) var(--g-button-border-color,var(--_--border-color));content:"";inset:0;position:absolute;transition:background-color .15s linear;z-index:-1}.g-button:hover{color:var(--g-button-text-color-hover,var(--_--text-color-hover))}.g-button:hover:before{background-color:var(--g-button-background-color-hover,var(--_--background-color-hover))}.g-button:focus-visible:before{outline:var(--g-button-focus-outline-color,var(--_--focus-outline-color)) var(--g-button-focus-outline-style,solid) var(--g-button-focus-outline-width,2px);outline-offset:var(--g-button-focus-outline-offset,var(--_--focus-outline-offset))}.g-button:after{content:"";inset:0;position:absolute;transform:scale(1);transition:none;z-index:-1}.g-button:active{transform:scale(.96);transition:none}.g-button:active:after{transform:scale(1.042)}.g-button_size_xs{--_--height:20px;--_--border-radius:var(--g-border-radius-xs);--_--padding:6px;--_--icon-size:12px;--_--icon-offset:4px}.g-button_size_s{--_--height:24px;--_--border-radius:var(--g-border-radius-s);--_--padding:8px;--_--icon-size:16px;--_--icon-offset:4px}.g-button_size_m{--_--height:28px;--_--border-radius:var(--g-border-radius-m);--_--padding:12px;--_--icon-size:16px;--_--icon-offset:8px}.g-button_size_l{--_--height:36px;--_--border-radius:var(--g-border-radius-l);--_--padding:16px;--_--icon-size:16px;--_--icon-offset:8px}.g-button_size_xl{--_--height:44px;--_--border-radius:var(--g-border-radius-xl);--_--padding:24px;--_--icon-size:20px;--_--icon-offset:12px;--_--font-size:var(--g-text-body-2-font-size)}.g-button_view_normal{--_--background-color:var(--g-color-base-generic);--_--background-color-hover:var(--g-color-base-generic-hover)}.g-button_view_action{--_--text-color:var(--g-color-text-brand-contrast);--_--background-color:var(--g-color-base-brand);--_--background-color-hover:var(--g-color-base-brand-hover);--_--focus-outline-color:var(--g-color-base-brand);--_--focus-outline-offset:1px}.g-button_view_outlined{--_--border-width:1px;--_--border-color:var(--g-color-line-generic)}.g-button_view_outlined-info{--_--text-color:var(--g-color-text-info);--_--border-width:1px;--_--border-color:var(--g-color-line-info)}.g-button_view_outlined-success{--_--text-color:var(--g-color-text-positive);--_--border-width:1px;--_--border-color:var(--g-color-line-positive)}.g-button_view_outlined-warning{--_--text-color:var(--g-color-text-warning);--_--border-width:1px;--_--border-color:var(--g-color-line-warning)}.g-button_view_outlined-danger{--_--text-color:var(--g-color-text-danger);--_--border-width:1px;--_--border-color:var(--g-color-line-danger)}.g-button_view_outlined-utility{--_--text-color:var(--g-color-text-utility);--_--border-width:1px;--_--border-color:var(--g-color-line-utility)}.g-button_view_outlined-action{--_--text-color:var(--g-color-text-brand);--_--border-width:1px;--_--border-color:var(--g-color-line-brand)}.g-button_view_raised{--_--background-color-hover:var(--g-color-base-float-hover);background:var(--g-color-base-float)}.g-button_view_raised:before{box-shadow:0 3px 5px var(--g-color-sfx-shadow)}.g-button_view_raised:active:before{box-shadow:0 1px 2px var(--g-color-sfx-shadow)}.g-button_view_flat-secondary{--_--text-color:var(--g-color-text-secondary);--_--text-color-hover:var(--g-color-text-primary)}.g-button_view_flat-info{--_--text-color:var(--g-color-text-info)}.g-button_view_flat-success{--_--text-color:var(--g-color-text-positive)}.g-button_view_flat-warning{--_--text-color:var(--g-color-text-warning)}.g-button_view_flat-danger{--_--text-color:var(--g-color-text-danger)}.g-button_view_flat-utility{--_--text-color:var(--g-color-text-utility)}.g-button_view_flat-action{--_--text-color:var(--g-color-text-brand)}.g-button_view_normal-contrast{--_--text-color:var(--g-color-text-dark-primary);--_--background-color:var(--g-color-base-light);--_--background-color-hover:var(--g-color-base-light-hover);--_--focus-outline-color:var(--g-color-line-light)}.g-button_view_normal-contrast.g-button_loading{--_--background-color-hover:var(--g-color-base-simple-hover)}.g-button_view_outlined-contrast{--_--text-color:var(--g-color-text-light-primary);--_--background-color-hover:var(--g-color-base-light-simple-hover);--_--border-width:1px;--_--border-color:var(--g-color-line-light);--_--focus-outline-color:var(--g-color-line-light)}.g-button_view_flat-contrast{--_--text-color:var(--g-color-text-light-primary);--_--background-color-hover:var(--g-color-base-light-simple-hover);--_--focus-outline-color:var(--g-color-line-light)}.g-button.g-button_pin_round-round.g-button{border-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-brick.g-button{border-radius:0}.g-button.g-button_pin_clear-clear.g-button{border-inline:0;border-radius:0}.g-button.g-button_pin_circle-circle.g-button{border-radius:100px}.g-button.g-button_pin_round-brick.g-button{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-round.g-button{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_round-clear.g-button{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_clear-round.g-button{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_brick-clear.g-button{border-inline-end:0;border-radius:0}.g-button.g-button_pin_clear-brick.g-button{border-inline-start:0;border-radius:0}.g-button.g-button_pin_circle-brick.g-button{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_brick-circle.g-button{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_circle-clear.g-button{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_clear-circle.g-button{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_round-round:before{border-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-brick:before{border-radius:0}.g-button.g-button_pin_clear-clear:before{border-inline:0;border-radius:0}.g-button.g-button_pin_circle-circle:before{border-radius:100px}.g-button.g-button_pin_round-brick:before{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-round:before{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_round-clear:before{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_clear-round:before{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_brick-clear:before{border-inline-end:0;border-radius:0}.g-button.g-button_pin_clear-brick:before{border-inline-start:0;border-radius:0}.g-button.g-button_pin_circle-brick:before{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_brick-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_circle-clear:before{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_clear-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_round-round:after{border-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-brick:after{border-radius:0}.g-button.g-button_pin_clear-clear:after{border-inline:0;border-radius:0}.g-button.g-button_pin_circle-circle:after{border-radius:100px}.g-button.g-button_pin_round-brick:after{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-round:after{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_round-clear:after{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_clear-round:after{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_brick-clear:after{border-inline-end:0;border-radius:0}.g-button.g-button_pin_clear-brick:after{border-inline-start:0;border-radius:0}.g-button.g-button_pin_circle-brick:after{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_brick-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_circle-clear:after{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_clear-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button__text{display:inline-block;white-space:nowrap}.g-button__icon{display:inline-block;height:var(--g-button-height,var(--_--height));margin:0 calc((var(--g-button-height, var(--_--height)) - var(--g-button-icon-size, var(--_--icon-size)))/2*-1);position:relative;width:var(--g-button-height,var(--_--height))}.g-button__icon:after{content:" ";visibility:hidden}.g-button__icon-inner{align-items:center;display:flex;inset:0;justify-content:center;position:absolute}.g-button__icon_side_start{order:-1}.g-button__icon_side_end{order:1}.g-button__icon:only-child{margin:0}.g-button:has(.g-button__icon:only-child){--_--padding:0}.g-button:has(.g-button__icon:only-child):not(.g-button_width_max){width:var(--g-button-height,var(--_--height))}.g-button_selected:not(.g-button_view_outlined-contrast){--_--border-width:0}.g-button_selected:not(.g-button_view_normal-contrast,.g-button_view_flat-contrast,.g-button_view_outlined-contrast){--_--text-color:var(--g-color-text-brand-heavy);--_--background-color:var(--g-color-base-selection);--_--background-color-hover:var(--g-color-base-selection-hover)}.g-button_selected.g-button_view_flat-info,.g-button_selected.g-button_view_outlined-info{--_--text-color:var(--g-color-text-info-heavy);--_--background-color:var(--g-color-base-info-light);--_--background-color-hover:var(--g-color-base-info-light-hover)}.g-button_selected.g-button_view_flat-success,.g-button_selected.g-button_view_outlined-success{--_--text-color:var(--g-color-text-positive-heavy);--_--background-color:var(--g-color-base-positive-light);--_--background-color-hover:var(--g-color-base-positive-light-hover)}.g-button_selected.g-button_view_flat-warning,.g-button_selected.g-button_view_outlined-warning{--_--text-color:var(--g-color-text-warning-heavy);--_--background-color:var(--g-color-base-warning-light);--_--background-color-hover:var(--g-color-base-warning-light-hover)}.g-button_selected.g-button_view_flat-danger,.g-button_selected.g-button_view_outlined-danger{--_--text-color:var(--g-color-text-danger-heavy);--_--background-color:var(--g-color-base-danger-light);--_--background-color-hover:var(--g-color-base-danger-light-hover)}.g-button_selected.g-button_view_flat-utility,.g-button_selected.g-button_view_outlined-utility{--_--text-color:var(--g-color-text-utility-heavy);--_--background-color:var(--g-color-base-utility-light);--_--background-color-hover:var(--g-color-base-utility-light-hover)}.g-button_disabled{cursor:default;pointer-events:none}.g-button_disabled:not(.g-button_loading){--_--text-color:var(--g-color-text-hint);--_--background-color:var(--g-color-base-generic-accent-disabled);--_--background-color-hover:var(--g-color-base-generic-accent-disabled);--_--border-width:0}.g-button_disabled:not(.g-button_loading):is(.g-button_view_normal-contrast,.g-button_view_outlined-contrast){--_--text-color:var(--g-color-text-light-secondary);--_--background-color:var(--g-color-base-light-disabled);--_--background-color-hover:var(--g-color-base-light-disabled)}.g-button_disabled:not(.g-button_loading):is(.g-button_view_flat,.g-button_view_flat-secondary,.g-button_view_flat-info,.g-button_view_flat-success,.g-button_view_flat-warning,.g-button_view_flat-danger,.g-button_view_flat-utility,.g-button_view_flat-action,.g-button_view_flat-contrast){--_--text-color:var(--g-color-text-hint);--_--background-color:#0000;--_--background-color-hover:#0000}.g-button_disabled:not(.g-button_loading).g-button_view_flat-contrast{--_--text-color:var(--g-color-text-light-hint)}.g-button_disabled:active{transform:scale(1)}.g-button_loading:before{animation:g-loading-animation .5s linear infinite;background-clip:padding-box;background-image:repeating-linear-gradient(-45deg,var(--g-button-background-color,var(--_--background-color)),var(--g-button-background-color,var(--_--background-color)) 4px,var(--g-button-background-color-hover,var(--_--background-color-hover)) 4px,var(--g-button-background-color-hover,var(--_--background-color-hover)) 8px);background-size:150%}.g-button_width_auto{max-width:100%}.g-button_width_max{width:100%}.g-button_width_auto .g-button__text,.g-button_width_max .g-button__text{display:block;overflow:hidden;text-overflow:ellipsis}.g-action-tooltip{--g-popup-border-width:0;--g-popup-background-color:var(--g-color-base-float-heavy)}.g-action-tooltip__content{box-sizing:border-box;color:var(--g-color-text-light-primary);max-width:300px;padding:6px 12px}.g-action-tooltip__heading{align-items:baseline;display:flex;justify-content:space-between}.g-action-tooltip__title{color:var(--g-color-text-light-primary)}.g-action-tooltip__hotkey{margin-inline-start:8px}.g-action-tooltip__description{color:var(--g-color-text-light-secondary);margin-block-start:4px}.g-popup{--_--background-color:var(--g-popup-background-color,var(--g-color-base-float));--_--border-color:var(--g-popup-border-color,var(--g-color-line-generic-solid));--_--border-width:var(--g-popup-border-width,1px);visibility:hidden;z-index:1000}.g-popup_exit_active,.g-popup_open{visibility:visible}.g-popup_exit_active[data-popper-placement*=bottom] .g-popup__content{animation-name:g-popup-bottom}.g-popup_exit_active[data-popper-placement*=top] .g-popup__content{animation-name:g-popup-top}.g-popup_exit_active[data-popper-placement*=left] .g-popup__content{animation-name:g-popup-left}.g-popup_exit_active[data-popper-placement*=right] .g-popup__content{animation-name:g-popup-right}.g-popup_appear_active[data-popper-placement*=bottom] .g-popup__content,.g-popup_enter_active[data-popper-placement*=bottom] .g-popup__content{animation-name:g-popup-bottom-open}.g-popup_appear_active[data-popper-placement*=top] .g-popup__content,.g-popup_enter_active[data-popper-placement*=top] .g-popup__content{animation-name:g-popup-top-open}.g-popup_appear_active[data-popper-placement*=left] .g-popup__content,.g-popup_enter_active[data-popper-placement*=left] .g-popup__content{animation-name:g-popup-left-open}.g-popup_appear_active[data-popper-placement*=right] .g-popup__content,.g-popup_enter_active[data-popper-placement*=right] .g-popup__content{animation-name:g-popup-right-open}.g-popup[data-popper-placement*=bottom] .g-popup__arrow{inset-block-start:-9px}.g-popup[data-popper-placement*=top] .g-popup__arrow{inset-block-end:-9px}.g-popup[data-popper-placement*=top] .g-popup__arrow-content{transform:rotate(180deg)}.g-popup[data-popper-placement*=left] .g-popup__arrow{right:-9px}.g-popup[data-popper-placement*=left] .g-popup__arrow-content{transform:rotate(90deg)}.g-popup[data-popper-placement*=right] .g-popup__arrow{left:-9px}.g-popup[data-popper-placement*=right] .g-popup__arrow-content{transform:rotate(-90deg)}.g-popup__content{animation-duration:.1s;animation-fill-mode:forwards;animation-timing-function:ease-out;background-color:var(--_--background-color);border-radius:4px;box-shadow:0 0 0 var(--_--border-width) var(--_--border-color),0 8px 20px var(--_--border-width) var(--g-color-sfx-shadow);outline:none;position:relative}.g-popup__content>.g-popup__arrow+*,.g-popup__content>:first-child:not(.g-popup__arrow){border-start-end-radius:inherit;border-start-start-radius:inherit}.g-popup__content>:last-child{border-end-end-radius:inherit;border-end-start-radius:inherit}.g-popup__arrow-content{display:flex;height:18px;overflow:hidden;position:relative;width:18px}.g-popup__arrow-circle-wrapper{background-color:initial;height:9px;overflow:hidden;position:relative;width:9px}.g-popup__arrow-circle{border-radius:50%;box-shadow:inset 0 0 0 calc(5px - var(--_--border-width)) var(--_--background-color),inset 0 0 0 5px var(--_--border-color);box-sizing:border-box;height:30px;position:absolute;width:28px}.g-popup__arrow-circle_left{inset-block-end:-4px;inset-inline-end:-5px}.g-popup__arrow-circle_right{inset-block-end:-4px;inset-inline-start:-5px}@keyframes g-popup-bottom{0%{opacity:1;transform:translateY(0)}to{opacity:0;transform:translateY(10px)}}@keyframes g-popup-bottom-open{0%{opacity:0;transform:translateY(10px)}to{opacity:1;transform:translateY(0)}}@keyframes g-popup-top{0%{opacity:1;transform:translateY(0)}to{opacity:0;transform:translateY(-10px)}}@keyframes g-popup-top-open{0%{opacity:0;transform:translateY(-10px)}to{opacity:1;transform:translateY(0)}}@keyframes g-popup-left{0%{opacity:1;transform:translateX(0)}to{opacity:0;transform:translateX(-10px)}}@keyframes g-popup-left-open{0%{opacity:0;transform:translateX(-10px)}to{opacity:1;transform:translateX(0)}}@keyframes g-popup-right{0%{opacity:1;transform:translateX(0)}to{opacity:0;transform:translateX(10px)}}@keyframes g-popup-right-open{0%{opacity:0;transform:translateX(10px)}to{opacity:1;transform:translateX(0)}}.g-portal__theme-wrapper{display:contents}.g-hotkey{border-radius:4px;padding:1px 5px}.g-hotkey,.g-hotkey kbd{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-hotkey_view_light{background-color:var(--g-color-base-generic)}.g-hotkey_view_light .g-hotkey__plus{color:var(--g-color-text-hint)}.g-hotkey_view_dark{background-color:var(--g-color-base-light-simple-hover);color:var(--g-color-text-light-complementary)}.g-hotkey_view_dark .g-hotkey__plus{color:var(--g-color-text-light-hint)}.g-help-mark__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.g-help-mark__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.g-link{-webkit-tap-highlight-color:rgba(0,0,0,0);border-radius:var(--g-focus-border-radius);cursor:pointer;text-decoration:none;touch-action:manipulation}.g-link:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-link_view_normal{color:var(--g-color-text-link)}.g-link_view_primary{color:var(--g-color-text-primary)}.g-link_view_secondary{color:var(--g-color-text-secondary)}.g-link_view_normal:hover,.g-link_view_primary:hover,.g-link_view_secondary:hover{color:var(--g-color-text-link-hover)}.g-link_visitable:visited{color:var(--g-color-text-link-visited)}.g-link_visitable:visited:hover{color:var(--g-color-text-link-visited-hover)}.g-link_underline{text-decoration:underline}.g-popover{display:inline-block;position:relative}.g-popover:not(.g-popover_disabled){cursor:pointer}.g-popover__handler{display:inline-block}.g-popover__tooltip{--_--padding:16px;--_--close-offset:8px;--_--close-size:24px}.g-popover__tooltip-popup-content{box-sizing:border-box;cursor:default;max-width:var(--g-popover-max-width,300px);min-height:40px;padding:var(--g-popover-padding,var(--_--padding))}.g-popover__tooltip-title{display:inline-flex;font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height);margin:0 0 12px}.g-popover__tooltip-buttons{display:flex;flex-wrap:wrap;gap:5px;margin-block-start:20px}.g-popover__tooltip-button{flex:1 1}.g-popover__tooltip-close{inset-block-start:var(--_--close-offset);inset-inline-end:var(--_--close-offset);position:absolute}.g-popover__tooltip-content{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height);overflow-wrap:break-word}.g-popover__tooltip-content_secondary{opacity:.7}.g-popover__tooltip-links>*{margin-block-start:8px}.g-popover__tooltip-links>:first-child{margin-block-start:0}.g-popover__tooltip-content+.g-popover__tooltip-links>:first-child{margin-block-start:12px}.g-popover__tooltip-link{display:inline-block;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-popover__tooltip_theme_announcement .g-popover__tooltip_theme_announcement,.g-popover__tooltip_theme_announcement.g-popover__tooltip_theme_info,.g-popover__tooltip_theme_info .g-popover__tooltip_theme_announcement,.g-popover__tooltip_theme_info.g-popover__tooltip_theme_info{color:var(--g-color-text-primary)}.g-popover__tooltip_force-links-appearance.g-popover__tooltip_theme_info .g-popover__tooltip-content a:not(.g-button),.g-popover__tooltip_theme_announcement .g-popover__tooltip-content a:not(.g-button){color:var(--g-color-text-link);text-decoration:none}.g-popover__tooltip_force-links-appearance.g-popover__tooltip_theme_info .g-popover__tooltip-content a:not(.g-button):hover,.g-popover__tooltip_theme_announcement .g-popover__tooltip-content a:not(.g-button):hover{color:var(--g-color-text-link-hover)}.g-popover__tooltip_theme_announcement{--g-popup-background-color:var(--g-color-base-simple-hover-solid);--g-popup-border-color:var(--g-color-base-simple-hover-solid)}.g-popover__tooltip_theme_special{--g-popup-background-color:var(--g-color-base-brand);--g-popup-border-color:var(--g-color-base-brand);color:var(--g-color-text-light-primary)}.g-popover__tooltip_theme_special .g-popover__tooltip-content a:not(.g-button){color:var(--g-color-text-light-primary);font-weight:var(--g-text-accent-font-weight)}.g-popover__tooltip_theme_special .g-popover__tooltip-content a:not(.g-button):hover{color:var(--g-color-text-light-secondary)}.g-popover__tooltip_theme_special .g-link{color:var(--g-color-text-light-primary)}.g-popover__tooltip_theme_special .g-link:hover{color:var(--g-color-text-light-secondary)}.g-popover__tooltip_size_l{--_--padding:24px}.g-popover__tooltip_size_l .g-popover__tooltip-title{font-family:var(--g-text-header-font-family);font-size:var(--g-text-header-1-font-size);font-weight:var(--g-text-header-font-weight);line-height:var(--g-text-header-1-line-height)}.g-popover__tooltip_size_l .g-popover__tooltip-content{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-popover__tooltip_with-close .g-popover__tooltip-content,.g-popover__tooltip_with-close .g-popover__tooltip-title{padding-inline-end:calc(var(--_--close-offset) + var(--_--close-size) - var(--_--padding))}.g-definition-list{--_--item-block-start:var(--g-spacing-4);--_--term-width:300px;margin:0}.g-definition-list__item{align-items:baseline;display:flex;gap:var(--g-spacing-1)}.g-definition-list__item+.g-definition-list__item{margin-block-start:var(--g-definition-list-item-gap,var(--_--item-block-start))}.g-definition-list__term-container{align-items:baseline;display:flex;flex:0 0 auto;max-width:var(--_--term-width);overflow:hidden;position:relative;width:var(--_--term-width)}.g-definition-list__term-wrapper{color:var(--g-color-text-secondary)}.g-definition-list__dots{border-block-end:1px dotted var(--g-color-line-generic-active);box-sizing:border-box;flex:1 0 auto;margin:0 2px;min-width:25px}.g-definition-list__definition{flex:0 1 auto;margin:0}.g-definition-list_responsive .g-definition-list__term-container{--_--term-width:auto;flex:1 0 min-content}.g-definition-list_vertical{--_--item-block-start:var(--g-spacing-3);--_--term-width:auto}.g-definition-list_vertical .g-definition-list__term-container{flex:1 0 auto}.g-definition-list_vertical .g-definition-list__item{flex-direction:column;gap:var(--g-spacing-half)}.g-definition-list__copy-container{align-items:center;display:inline-flex;margin-inline-end:calc(var(--g-spacing-7)*-1);padding-inline-end:var(--g-spacing-7);position:relative}.g-definition-list__copy-container:hover .g-definition-list__copy-button{opacity:1}.g-definition-list__copy-button{display:inline-block;inset-inline-end:0;margin-inline-start:10px;opacity:0;position:absolute}.g-definition-list__copy-button:focus-visible{opacity:1}.g-switch{position:relative}.g-switch__control{cursor:pointer;opacity:0}.g-switch__indicator{display:inline-block;position:relative}.g-switch__indicator:before{background-color:var(--g-color-base-generic-medium);content:"";inset:0;position:absolute;transition:background .1s linear}.g-switch__indicator:after{content:" ";visibility:hidden}.g-switch__slider{background-color:var(--g-color-base-background);border-radius:50%;content:"";position:absolute;transition:transform .15s ease-out}.g-switch__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;pointer-events:none;position:absolute;width:100%}.g-switch__control:focus-visible+.g-switch__outline{outline:2px solid var(--g-color-line-focus)}.g-switch_size_m .g-switch__indicator,.g-switch_size_m .g-switch__indicator:before,.g-switch_size_m .g-switch__outline{border-radius:10px;height:20px;width:36px}.g-switch_size_m .g-switch__slider{height:16px;inset-block-start:2px;inset-inline-start:2px;width:16px}.g-switch_size_m .g-switch__text{margin-block-start:3px}.g-switch_size_l .g-switch__indicator,.g-switch_size_l .g-switch__indicator:before,.g-switch_size_l .g-switch__outline{border-radius:12px;height:24px;width:42px}.g-switch_size_l .g-switch__slider{height:18px;inset-block-start:3px;inset-inline-start:3px;width:18px}.g-switch_size_l .g-switch__text{margin-block-start:4px}.g-switch:hover .g-switch__indicator:before{background-color:var(--g-color-base-generic-medium-hover)}.g-switch_checked .g-switch__slider{--_--translate-x:calc(100%*var(--g-flow-direction));transform:translateX(var(--_--translate-x))}.g-switch_checked .g-switch__indicator:before,.g-switch_checked:hover .g-switch__indicator:before{background-color:var(--g-color-base-brand)}.g-switch_disabled .g-switch__indicator:before{background-color:var(--g-color-base-generic-accent-disabled)}.g-switch_disabled.g-switch_checked .g-switch__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.g-control-label{-webkit-tap-highlight-color:rgba(0,0,0,0);color:var(--g-color-text-primary);cursor:pointer;display:inline-flex;font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight);touch-action:manipulation;-webkit-user-select:none;user-select:none}.g-control-label_disabled{cursor:default;pointer-events:none}.g-control-label_size_m{font-size:var(--g-text-body-1-font-size);line-height:15px}.g-control-label_size_l{font-size:var(--g-text-body-2-font-size);line-height:18px}.g-control-label__indicator{flex-shrink:0}.g-control-label__text{flex-grow:1;white-space:normal}.g-control-label_disabled .g-control-label__text{opacity:.6}.g-control-label_size_m .g-control-label__text{margin-inline-start:5px}.g-control-label_size_l .g-control-label__text{margin-inline-start:7px}.g-radio-button{--_--border-radius-inner:calc(var(--_--border-radius) - 3px);background-color:var(--g-color-base-generic);border-radius:var(--_--border-radius);box-sizing:border-box;display:inline-flex;flex-direction:row;font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight);position:relative}.g-radio-button__plate{inset-block:0;position:absolute;transition:left .2s,width .2s}.g-radio-button__plate[hidden]{display:none}.g-radio-button__option{border-radius:var(--_--border-radius-inner);cursor:pointer;flex:1 1 auto;font-size:var(--g-text-body-1-font-size);text-align:center;transform:scale(1);transition:color .15s linear;-webkit-user-select:none;user-select:none}.g-radio-button__option-outline{border-radius:var(--_--border-radius-inner);content:"";inset:3px;position:absolute;z-index:-1}.g-radio-button__option-control{border:none;cursor:inherit;height:100%;inset-block-start:0;inset-inline-start:0;margin:0;opacity:0;outline:none;padding:0;position:absolute;width:100%}.g-radio-button__option-control:focus-visible+.g-radio-button__option-outline{outline:2px solid var(--g-color-line-focus)}.g-radio-button__option-text{color:var(--g-color-text-complementary);display:inline-block;white-space:nowrap}.g-radio-button__option-text_icon{align-items:center;display:flex;height:100%}.g-radio-button__option:hover .g-radio-button__option-text,.g-radio-button__option_checked .g-radio-button__option-text{color:var(--g-color-text-primary)}.g-radio-button__option_checked{cursor:default}.g-radio-button__option_disabled{cursor:default;pointer-events:none}.g-radio-button__option_disabled .g-radio-button__option-text{color:var(--g-color-text-hint)}.g-radio-button__option:before,.g-radio-button__plate:before{border-radius:var(--_--border-radius-inner);inset:3px;position:absolute}.g-radio-button__option:before{z-index:-1}.g-radio-button__plate:before,.g-radio-button__plate[hidden]~.g-radio-button__option_checked:before{background-color:var(--g-color-base-background);content:""}.g-radio-button_size_s{--_--border-radius:var(--g-border-radius-s)}.g-radio-button_size_s .g-radio-button__option{height:24px;line-height:24px}.g-radio-button_size_s .g-radio-button__option-text{margin:0 10px}.g-radio-button_size_m{--_--border-radius:var(--g-border-radius-m)}.g-radio-button_size_m .g-radio-button__option{height:28px;line-height:28px}.g-radio-button_size_m .g-radio-button__option-text{margin:0 13px}.g-radio-button_size_l{--_--border-radius:var(--g-border-radius-l)}.g-radio-button_size_l .g-radio-button__option{height:36px;line-height:36px}.g-radio-button_size_l .g-radio-button__option-text{margin:0 18px}.g-radio-button_size_xl{--_--border-radius:var(--g-border-radius-xl)}.g-radio-button_size_xl .g-radio-button__option{font-size:var(--g-text-body-2-font-size);height:44px;line-height:44px}.g-radio-button_size_xl .g-radio-button__option-text{margin:0 25px}.g-radio-button_width_auto{max-width:100%}.g-radio-button_width_max{width:100%}.g-radio-button_width_auto .g-radio-button__option,.g-radio-button_width_max .g-radio-button__option{overflow:hidden}.g-radio-button_width_auto .g-radio-button__option-text,.g-radio-button_width_max .g-radio-button__option-text{display:block;overflow:hidden;text-overflow:ellipsis}.g-label{--_--bg-color:none;--_--bg-color-hover:none;--_--text-color:none;align-items:center;background-color:var(--_--bg-color);border-radius:var(--_--border-radius);box-sizing:border-box;color:var(--_--text-color);display:inline-flex;height:var(--_--height);isolation:isolate;position:relative;transition-duration:.15s;transition-property:opacity,color,background-color;transition-timing-function:ease-in-out}.g-label__text{align-items:baseline;display:flex;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height);line-height:var(--_--height);margin:0 var(--_--margin-inline);overflow:hidden;text-align:center;white-space:nowrap;width:100%}.g-label__content,.g-label__key{overflow:hidden;text-overflow:ellipsis}.g-label__value{display:flex;opacity:.7;overflow:hidden}.g-label__separator{margin:0 4px}.g-label__main-button{background:none;border:none;border-radius:inherit;color:inherit;cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;z-index:1}.g-label__main-button:empty{inset:0;position:absolute}.g-label__addon{align-items:center;border-radius:var(--_--border-radius);display:flex;height:var(--_--height);justify-content:center;width:var(--_--height)}.g-label__addon_side_end,.g-label__addon_side_start{inset-block-start:0;position:absolute}.g-label__addon_side_start{border-end-end-radius:0;border-start-end-radius:0;inset-inline-start:2px}.g-label__addon_side_end{border-end-start-radius:0;border-start-start-radius:0;inset-inline-end:0}.g-label__addon_type_button{background:none;background-color:initial;border:none;color:inherit;color:var(--_--text-color);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;transition:color .15s ease-in-out,background-color .15s ease-in-out,transform .1s ease-out;z-index:2}.g-label__addon_type_button:active{transform:scale(.96)}.g-label_size_xs{--_--height:20px;--_--border-radius:var(--g-border-radius-xs);--_--margin-inline:8px;--_--margin-addon-start:24px;--_--margin-addon-end:22px}.g-label_size_s{--_--height:24px;--_--border-radius:var(--g-border-radius-s);--_--margin-inline:10px;--_--margin-addon-start:28px;--_--margin-addon-end:26px}.g-label_size_m{--_--height:28px;--_--border-radius:var(--g-border-radius-m);--_--margin-inline:12px;--_--margin-addon-start:32px;--_--margin-addon-end:32px}.g-label_disabled{opacity:.7;pointer-events:none}.g-label_interactive{cursor:pointer}.g-label_theme_normal{--_--bg-color:var(--g-color-base-misc-light);--_--bg-color-hover:var(--g-color-base-misc-light-hover);--_--text-color:var(--g-color-text-misc-heavy)}.g-label_theme_success{--_--bg-color:var(--g-color-base-positive-light);--_--bg-color-hover:var(--g-color-base-positive-light-hover);--_--text-color:var(--g-color-text-positive-heavy)}.g-label_theme_info{--_--bg-color:var(--g-color-base-info-light);--_--bg-color-hover:var(--g-color-base-info-light-hover);--_--text-color:var(--g-color-text-info-heavy)}.g-label_theme_warning{--_--bg-color:var(--g-color-base-warning-light);--_--bg-color-hover:var(--g-color-base-warning-light-hover);--_--text-color:var(--g-color-text-warning-heavy)}.g-label_theme_danger{--_--bg-color:var(--g-color-base-danger-light);--_--bg-color-hover:var(--g-color-base-danger-light-hover);--_--text-color:var(--g-color-text-danger-heavy)}.g-label_theme_utility{--_--bg-color:var(--g-color-base-utility-light);--_--bg-color-hover:var(--g-color-base-utility-light-hover);--_--text-color:var(--g-color-text-utility-heavy)}.g-label_theme_unknown{--_--bg-color:var(--g-color-base-neutral-light);--_--bg-color-hover:var(--g-color-base-neutral-light-hover);--_--text-color:var(--g-color-text-complementary)}.g-label_theme_clear{--_--bg-color:#0000;--_--bg-color-hover:var(--g-color-base-simple-hover);--_--text-color:var(--g-color-text-complementary);box-shadow:inset 0 0 0 1px var(--g-color-line-generic)}.g-label:has(.g-label__addon_side_start) .g-label__text{margin-inline-start:var(--_--margin-addon-start)}.g-label:has(.g-label__addon_side_end) .g-label__text{margin-inline-end:var(--_--margin-addon-end)}.g-label__addon_type_button:hover,.g-label_interactive:hover:not(:has(.g-label__addon_type_button:hover)){background-color:var(--_--bg-color-hover)}.g-label__addon_type_button:focus-visible,.g-label__main-button:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-tabs{--_--vertical-item-padding:var(--g-tabs-vertical-item-padding,6px 20px);--_--vertical-item-height:var(--g-tabs-vertical-item-height,18px)}.g-tabs_size_m{--_--item-height:36px;--_--item-gap:24px;--_--item-border-width:2px}.g-tabs_size_m .g-tabs__item-counter,.g-tabs_size_m .g-tabs__item-title{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-tabs_size_l{--_--item-height:40px;--_--item-gap:28px;--_--item-border-width:2px}.g-tabs_size_l .g-tabs__item-counter,.g-tabs_size_l .g-tabs__item-title{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-tabs_size_xl{--_--item-height:44px;--_--item-gap:32px;--_--item-border-width:3px}.g-tabs_size_xl .g-tabs__item-counter,.g-tabs_size_xl .g-tabs__item-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-tabs__item{cursor:pointer;outline:none;-webkit-user-select:none;user-select:none}.g-tabs__item-content{align-items:center;border-radius:var(--g-focus-border-radius);display:flex}.g-tabs__item_overflow .g-tabs__item-content{min-width:0}.g-tabs__item-icon{margin-inline-end:8px}.g-tabs__item-title{white-space:nowrap}.g-tabs__item_overflow .g-tabs__item-title{overflow:hidden;text-overflow:ellipsis}.g-tabs__item-counter,.g-tabs__item-label{margin-inline-start:8px}.g-tabs__item-icon>svg{display:block}.g-tabs_direction_horizontal{align-items:flex-end;box-shadow:inset 0 calc(var(--g-tabs-border-width, 1px)*-1) 0 0 var(--g-color-line-generic);display:flex;flex-wrap:wrap;overflow:hidden}.g-tabs_direction_horizontal .g-tabs__item{align-items:center;border-block-end:var(--g-tabs-item-border-width,var(--_--item-border-width)) solid #0000;box-sizing:border-box;display:flex;height:var(--g-tabs-item-height,var(--_--item-height));padding-block-start:var(--_--item-border-width)}.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-content{outline:2px solid var(--g-color-line-focus);outline-offset:-2px}.g-tabs_direction_horizontal .g-tabs__item-meta{display:none}.g-tabs_direction_horizontal .g-tabs__item-title{color:var(--g-color-text-secondary)}.g-tabs_direction_horizontal .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item-icon{color:var(--g-color-text-hint)}.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-title,.g-tabs_direction_horizontal .g-tabs__item:hover .g-tabs__item-title,.g-tabs_direction_horizontal .g-tabs__item_active .g-tabs__item-title{color:var(--g-color-text-primary)}.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-icon,.g-tabs_direction_horizontal .g-tabs__item:hover .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item:hover .g-tabs__item-icon,.g-tabs_direction_horizontal .g-tabs__item_active .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item_active .g-tabs__item-icon{color:var(--g-color-text-secondary)}.g-tabs_direction_horizontal .g-tabs__item_active,.g-tabs_direction_horizontal .g-tabs__item_active:focus-visible,.g-tabs_direction_horizontal .g-tabs__item_active:hover{border-color:var(--g-color-line-brand)}.g-tabs_direction_horizontal .g-tabs__item_disabled{pointer-events:none}.g-tabs_direction_horizontal .g-tabs__item_disabled .g-tabs__item-title{color:var(--g-color-text-hint)}.g-tabs_direction_horizontal>:not(:last-child){margin-inline-end:var(--g-tabs-item-gap,var(--_--item-gap))}.g-tabs_direction_vertical{display:flex;flex-direction:column}.g-tabs_direction_vertical .g-tabs__item{padding:var(--_--vertical-item-padding)}.g-tabs_direction_vertical .g-tabs__item-title{color:var(--g-color-text-primary);line-height:var(--_--vertical-item-height)}.g-tabs_direction_vertical .g-tabs__item-meta{color:var(--g-color-text-secondary);line-height:var(--_--vertical-item-height)}.g-tabs_direction_vertical .g-tabs__item-counter,.g-tabs_direction_vertical .g-tabs__item-icon{color:var(--g-color-text-secondary)}.g-tabs_direction_vertical .g-tabs__item:focus-visible,.g-tabs_direction_vertical .g-tabs__item:hover{background-color:var(--g-color-base-generic-hover)}.g-tabs_direction_vertical .g-tabs__item_active{background-color:var(--g-color-base-selection)}.g-tabs_direction_vertical .g-tabs__item_active:focus-visible,.g-tabs_direction_vertical .g-tabs__item_active:hover{background-color:var(--g-color-base-selection-hover)}.g-tabs_direction_vertical .g-tabs__item_disabled{pointer-events:none}.g-tabs_direction_vertical .g-tabs__item_disabled .g-tabs__item-title{color:var(--g-color-text-secondary)}.g-outer-additional-content{display:flex;justify-content:space-between;vertical-align:top}.g-outer-additional-content__error,.g-outer-additional-content__note{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height);margin-block-start:2px}.g-outer-additional-content__error{color:var(--g-color-text-danger)}.g-outer-additional-content__error:not(:last-child){margin-inline-end:var(--g-spacing-2)}.g-outer-additional-content__note{margin-inline-start:auto}.g-text-input{--_--text-color:var(--g-color-text-primary);--_--label-color:inherit;--_--placeholder-color:var(--g-color-text-hint);--_--background-color:#0000;--_--border-width:1px;--_--focus-outline-color:var(--g-text-input-focus-outline-color);display:inline-block;position:relative;width:100%}.g-text-input__content{background-color:var(--g-text-input-background-color,var(--_--background-color));border-color:var(--g-text-input-border-color,var(--_--border-color));border-style:solid;border-width:var(--g-text-input-border-width,var(--_--border-width));box-sizing:border-box;color:var(--g-text-input-text-color,var(--_--text-color));display:flex;overflow:hidden;width:100%}.g-text-input__content:hover{border-color:var(--g-text-input-border-color-hover,var(--_--border-color-hover))}.g-text-input__content:focus-within{border-color:var(--g-text-input-border-color-active,var(--_--border-color-active));outline:2px solid var(--g-text-input-focus-outline-color,var(--_--focus-outline-color));outline-offset:-1px}.g-text-input__control{background-color:initial;border:none;box-sizing:border-box;color:inherit;display:inline-block;flex-grow:1;font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight);height:var(--g-text-input-height);margin:0;padding:0;position:relative;vertical-align:top;width:100%}.g-text-input__control::placeholder{color:var(--g-text-input-placeholder-color,var(--_--placeholder-color));overflow:hidden;white-space:nowrap}.g-text-input__control:focus{outline:none}.g-text-input__control[type=number]{appearance:textfield}.g-text-input__label{box-sizing:border-box;color:var(--g-text-input-label-color,var(--_--label-color));overflow:hidden;position:absolute;text-overflow:ellipsis;white-space:nowrap;z-index:1}.g-text-input__clear{flex-shrink:0;margin:auto 0}.g-text-input__clear_size_m,.g-text-input__clear_size_s{margin-inline-end:1px}.g-text-input__clear_size_l,.g-text-input__clear_size_xl{margin-inline-end:2px}.g-text-input__error-icon{box-sizing:initial;color:var(--g-color-text-danger);padding-block:var(--_--error-icon-padding-block);padding-inline:var(--_--error-icon-padding-inline)}.g-text-input__additional-content{align-items:center;display:flex}.g-text-input_size_s{--_--error-icon-padding-block:5px;--_--error-icon-padding-inline:0 5px;--_--border-radius:var(--g-border-radius-s)}.g-text-input_size_s .g-text-input__control{--_--input-control-border-width:var( + --g-text-input-border-width,var(--g-text-area-border-width,1px) + );height:calc(24px - var(--_--input-control-border-width)*2);padding:3px 8px}.g-text-input_size_s .g-text-input__control,.g-text-input_size_s .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-text-input_size_s .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:3px;padding-inline:8px 4px}.g-text-input_size_s.g-text-input_has-start-content .g-text-input__label{padding-inline-start:2px}.g-text-input_size_s .g-text-input__additional-content{height:22px}.g-text-input_size_s .g-text-input__additional-content_placement_start{padding-inline-start:1px}.g-text-input_size_s .g-text-input__additional-content_placement_end{padding-inline-end:1px}.g-text-input_size_m{--_--error-icon-padding-block:5px;--_--error-icon-padding-inline:0 5px;--_--border-radius:var(--g-border-radius-m)}.g-text-input_size_m .g-text-input__control{--_--input-control-border-width:var( + --g-text-input-border-width,var(--g-text-area-border-width,1px) + );height:calc(28px - var(--_--input-control-border-width)*2);padding:5px 8px}.g-text-input_size_m .g-text-input__control,.g-text-input_size_m .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-text-input_size_m .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:5px;padding-inline:8px 4px}.g-text-input_size_m.g-text-input_has-start-content .g-text-input__label{padding-inline-start:2px}.g-text-input_size_m .g-text-input__additional-content{height:26px}.g-text-input_size_m .g-text-input__additional-content_placement_start{padding-inline-start:1px}.g-text-input_size_m .g-text-input__additional-content_placement_end{padding-inline-end:1px}.g-text-input_size_l{--_--error-icon-padding-block:9px;--_--error-icon-padding-inline:0 9px;--_--border-radius:var(--g-border-radius-l)}.g-text-input_size_l .g-text-input__control{--_--input-control-border-width:var( + --g-text-input-border-width,var(--g-text-area-border-width,1px) + );height:calc(36px - var(--_--input-control-border-width)*2);padding:9px 12px}.g-text-input_size_l .g-text-input__control,.g-text-input_size_l .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-text-input_size_l .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:9px;padding-inline:12px 4px}.g-text-input_size_l.g-text-input_has-start-content .g-text-input__label{padding-inline-start:3px}.g-text-input_size_l .g-text-input__additional-content{height:34px}.g-text-input_size_l .g-text-input__additional-content_placement_start{padding-inline-start:3px}.g-text-input_size_l .g-text-input__additional-content_placement_end{padding-inline-end:3px}.g-text-input_size_xl{--_--error-icon-padding-block:13px;--_--error-icon-padding-inline:0 13px;--_--border-radius:var(--g-border-radius-xl)}.g-text-input_size_xl .g-text-input__control{--_--input-control-border-width:var( + --g-text-input-border-width,var(--g-text-area-border-width,1px) + );height:calc(44px - var(--_--input-control-border-width)*2);padding:11px 12px}.g-text-input_size_xl .g-text-input__control,.g-text-input_size_xl .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-text-input_size_xl .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:11px;padding-inline:12px 4px}.g-text-input_size_xl.g-text-input_has-start-content .g-text-input__label{padding-inline-start:3px}.g-text-input_size_xl .g-text-input__additional-content{height:42px}.g-text-input_size_xl .g-text-input__additional-content_placement_start{padding-inline-start:3px}.g-text-input_size_xl .g-text-input__additional-content_placement_end{padding-inline-end:3px}.g-text-input_view_normal{--_--border-color:var(--g-color-line-generic);--_--border-color-hover:var(--g-color-line-generic-hover);--_--border-color-active:var(--g-color-line-generic-active)}.g-text-input_view_clear{--_--border-color:#0000;--_--border-color-hover:#0000;--_--border-color-active:#0000;--_--border-radius:0}.g-text-input_view_clear .g-text-input__content{border-inline:0}.g-text-input_view_clear .g-text-input__control{padding-inline:0}.g-text-input.g-text-input_pin_round-round .g-text-input__content{border-radius:var(--g-text-input-border-radius,var(--_--border-radius))}.g-text-input.g-text-input_pin_brick-brick .g-text-input__content{border-radius:0}.g-text-input.g-text-input_pin_clear-clear .g-text-input__content{border-inline:0;border-radius:0}.g-text-input.g-text-input_pin_circle-circle .g-text-input__content{border-radius:100px}.g-text-input.g-text-input_pin_round-brick .g-text-input__content{border-end-end-radius:0;border-end-start-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-text-input-border-radius,var(--_--border-radius))}.g-text-input.g-text-input_pin_brick-round .g-text-input__content{border-end-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-text-input.g-text-input_pin_round-clear .g-text-input__content{border-end-end-radius:0;border-end-start-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-text-input-border-radius,var(--_--border-radius))}.g-text-input.g-text-input_pin_clear-round .g-text-input__content{border-end-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-text-input.g-text-input_pin_brick-clear .g-text-input__content{border-inline-end:0;border-radius:0}.g-text-input.g-text-input_pin_clear-brick .g-text-input__content{border-inline-start:0;border-radius:0}.g-text-input.g-text-input_pin_circle-brick .g-text-input__content{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-text-input.g-text-input_pin_brick-circle .g-text-input__content{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-text-input.g-text-input_pin_circle-clear .g-text-input__content{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-text-input.g-text-input_pin_clear-circle .g-text-input__content{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-text-input_disabled{--_--text-color:var(--g-color-text-hint);--_--background-color:var(--g-color-base-generic-accent-disabled);--_--border-color:#0000;--_--border-color-hover:#0000;--_--border-color-active:#0000}.g-text-input_has-scrollbar .g-text-input__clear{inset-inline-end:var(--g-scrollbar-width)}.g-text-input_has-start-content .g-text-input__control{padding-inline-start:2px}.g-text-input_has-end-content .g-text-input__control{padding-inline-end:2px}.g-text-input_has-unstable-end-content{--_--error-icon-padding-inline:0}.g-text-input_state_error.g-text-input_view_normal .g-text-input__content,.g-text-input_state_error.g-text-input_view_normal .g-text-input__content:focus-within,.g-text-input_state_error.g-text-input_view_normal .g-text-input__content:hover{border-color:var(--g-color-line-danger)}.g-text-input_state_error.g-text-input_view_normal .g-text-input__content:focus-within{--_--focus-outline-color:var(--g-color-line-danger)}.g-text-input_state_error.g-text-input_view_clear .g-text-input__content,.g-text-input_state_error.g-text-input_view_clear .g-text-input__content:focus-within,.g-text-input_state_error.g-text-input_view_clear .g-text-input__content:hover{border-block-end:1px solid var(--g-color-line-danger)}.g-text-input_state_error.g-text-input_view_clear .g-text-input__content:focus-within{--_--focus-outline-color:var(--g-color-line-danger)}.g-clear-button{--g-button-text-color:var(--g-color-text-hint);--g-button-text-color-hover:var(--g-color-text-primary);--g-button-background-color:#0000;--g-button-background-color-hover:#0000}@keyframes g-pulse{50%{opacity:15%}}.g-loader{align-items:center;display:inline-flex}.g-loader__center,.g-loader__left,.g-loader__right{animation:g-pulse .8s ease infinite;background:var(--g-color-base-brand)}.g-loader__left{animation-delay:.2s}.g-loader__center{animation-delay:.4s}.g-loader__right{animation-delay:.6s}.g-loader_size_s .g-loader__left{height:13.33333px;width:5px}.g-loader_size_s .g-loader__center{height:20px;margin-inline-start:5px;width:5px}.g-loader_size_s .g-loader__right{height:13.33333px;margin-inline-start:5px;width:5px}.g-loader_size_m .g-loader__left{height:18.66667px;width:7px}.g-loader_size_m .g-loader__center{height:28px;margin-inline-start:7px;width:7px}.g-loader_size_m .g-loader__right{height:18.66667px;margin-inline-start:7px;width:7px}.g-loader_size_l .g-loader__left{height:24px;width:9px}.g-loader_size_l .g-loader__center{height:36px;margin-inline-start:9px;width:9px}.g-loader_size_l .g-loader__right{height:24px;margin-inline-start:9px;width:9px}.kv-ydb-internal-user{align-items:center;display:flex;flex-grow:1;justify-content:space-between;line-height:var(--g-text-body-2-line-height);margin-left:16px}.kv-ydb-internal-user__user-info-wrapper{display:flex;flex-direction:column}.kv-ydb-internal-user__ydb-internal-user-title{font-weight:500}.kv-ydb-internal-user__ydb-user-wrapper{padding:10px;width:300px}.ydb-link-with-icon{align-items:center;display:inline-flex;flex-wrap:nowrap;white-space:nowrap}.ydb-node-endpoints-tooltip-content .info-viewer__value{min-width:70px}.ydb-node-endpoints-tooltip-content__list-container{padding-right:20px}.ydb-node-endpoints-tooltip-content__definition{text-align:right;word-break:break-word}.info-viewer{--ydb-info-viewer-font-size:var(--g-text-body-2-font-size);--ydb-info-viewer-line-height:var(--g-text-body-2-line-height);--ydb-info-viewer-title-font-weight:600;--ydb-info-viewer-title-margin:15px 0 10px;--ydb-info-viewer-items-gap:7px;font-size:var(--ydb-info-viewer-font-size);line-height:var(--ydb-info-viewer-line-height)}.info-viewer__title{font-weight:var(--ydb-info-viewer-title-font-weight);margin:var(--ydb-info-viewer-title-margin)}.info-viewer__items{display:flex;flex-direction:column;gap:var(--ydb-info-viewer-items-gap);max-width:100%}.info-viewer__row{align-items:baseline;display:flex;max-width:100%;padding-top:4px}.info-viewer__label{align-items:baseline;color:var(--g-color-text-secondary);display:flex;flex:0 1 auto;min-width:200px;white-space:nowrap}.info-viewer__label-text_multiline{max-width:180px;overflow:visible;white-space:normal}.info-viewer__dots{border-bottom:1px dotted var(--g-color-text-secondary);display:flex;flex:1 1 auto;margin:0 2px}.info-viewer__value{display:flex;min-width:130px;word-break:break-all}.info-viewer_size_s{--ydb-info-viewer-font-size:var(--g-text-body-1-font-size);--ydb-info-viewer-line-height:var(--g-text-body-1-line-height);--ydb-info-viewer-title-font-weight:500;--ydb-info-viewer-title-margin:0 0 4px;--ydb-info-viewer-items-gap:4px}.info-viewer_size_s .info-viewer__row{height:auto}.info-viewer_size_s .info-viewer__label{min-width:85px}.ydb-cell-with-popover{display:inline-flex;max-width:100%}.ydb-cell-with-popover_full-width{display:flex}.ydb-cell-with-popover__popover{display:inline-block;max-width:100%;overflow:hidden;text-overflow:ellipsis;vertical-align:middle;white-space:nowrap}.ydb-cell-with-popover__popover .g-popover__handler{display:inline}.ydb-cell-with-popover__popover_full-width{width:100%}.popup2{animation:none!important;max-width:300px}.histogram-tooltip,.node-tootltip{padding:10px}.histogram-tooltip__label,.node-tootltip__label{color:var(--g-color-text-secondary);padding-right:15px}.cell-tooltip{padding:10px;word-break:break-word}.empty-state{padding:20px}.empty-state_size_m{height:400px}.empty-state__wrapper{display:grid;grid-template-areas:"image title" "image description" "image actions"}.empty-state__wrapper_size_s{height:120px;width:460px}.empty-state__wrapper_size_m{height:240px;width:800px}.empty-state__wrapper_position_center{margin:0 auto;position:relative}.empty-state__wrapper_position_left{margin:unset}.empty-state__image{color:var(--g-color-base-info-light-hover);grid-area:image;justify-self:end;margin-right:60px}.g-root_theme_dark .empty-state__image{color:var(--g-color-base-generic)}.empty-state__title{align-self:center;font-weight:500;grid-area:title}.empty-state__title_size_s{font-size:var(--g-text-subheader-3-font-size);line-height:var(--g-text-subheader-3-line-height)}.empty-state__title_size_m{font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.empty-state__description{font-size:var(--g-text-body-2-font-size);grid-area:description;line-height:var(--g-text-body-2-line-height)}.empty-state__actions{grid-area:actions}.empty-state__actions>*{margin-right:8px}.ydb-loader{flex:1 1 auto}.authentication,.ydb-loader{align-items:center;display:flex;height:100%;justify-content:center}.authentication{background-blend-mode:normal;background-color:#b8d4fd1a;background-image:radial-gradient(at 0 100%,#0066ff26 20%,#f7f7f700 40%),radial-gradient(at 55% 0,#0066ff26 20%,#f7f7f700 40%),radial-gradient(at 110% 100%,#0066ff26 20%,#f7f7f700 40%)}.authentication .g-text-input{display:flex}.authentication__header{align-items:center;display:flex;font-size:var(--g-text-body-1-font-size);justify-content:space-between;line-height:var(--g-text-header-1-line-height);width:100%}.authentication__logo{align-items:center;display:flex;font-size:16px;font-weight:600;gap:8px}.authentication__title{font-size:var(--g-text-header-2-font-size);font-weight:600;line-height:var(--g-text-header-2-line-height);margin:34px 0 16px}.authentication__form-wrapper{align-items:center;background-color:var(--g-color-base-background);border-radius:16px;display:flex;flex-direction:column;flex-shrink:0;justify-content:center;min-width:320px;padding:40px;width:400px}.authentication__field-wrapper{align-items:flex-start;display:flex;justify-content:space-between;margin-bottom:16px;width:320px}.authentication__field-wrapper .g-text-input_state_error{flex-direction:column}.authentication__button-sign-in{display:inline-flex;justify-content:center}.authentication__show-password-button{margin-left:4px}.authentication__close{position:absolute;right:40px;top:40px}.ydb-connect-to-db__dialog-tabs,.ydb-connect-to-db__docs{margin-top:var(--g-spacing-4)}.ydb-connect-to-db__snippet-container{height:270px}.g-dialog-btn-close{inset-block-start:14px;inset-inline-end:14px;position:absolute;z-index:1}.g-dialog-body{flex:1 1 auto;overflow-y:auto;padding:10px var(--_--side-padding)}.g-dialog-body_has-borders{border-block-end:1px solid var(--g-color-line-generic)}.g-dialog-body_has-borders,.g-dialog-divider{border-block-start:1px solid var(--g-color-line-generic)}.g-dialog-divider{margin:0 calc(var(--_--side-padding)*-1)}.g-dialog-footer{align-items:center;display:flex;padding:28px var(--_--side-padding)}.g-dialog-footer__bts-wrapper{display:flex;gap:10px}.g-dialog-footer__children{align-items:center;display:flex;flex-grow:1;height:100%}.g-dialog-footer__button{min-width:128px;position:relative}.g-dialog-footer__error{color:var(--g-color-text-danger);padding:10px}.g-dialog-header{align-items:center;color:var(--g-color-text-primary);display:flex;justify-content:flex-start;line-height:24px;padding-block:20px 10px;padding-inline:var(--_--side-padding) calc(var(--_--side-padding) + var(--_--close-button-space)*var(--g-flow-is-ltr) + var(--_--close-button-space)*var(--g-flow-is-rtl))}.g-dialog-header__caption{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-dialog{--_--side-padding:32px;--_--close-button-space:0px;display:flex;flex-direction:column;position:relative;width:var(--g-dialog-width,var(--_--width))}.g-dialog_has-scroll{max-height:calc(100vh - var(--g-modal-margin, 20px)*2);overflow-y:auto}.g-dialog_size_s{--_--width:480px}.g-dialog_size_m{--_--width:720px}.g-dialog_size_l{--_--width:900px}.g-dialog_has-close{--_--close-button-space:24px}.g-modal{-webkit-overflow-scrolling:touch;-webkit-tap-highlight-color:rgba(0,0,0,0);background-color:var(--g-color-sfx-veil);display:none;inset:0;margin:-9999px 0 0 -9999px;overflow:auto;position:fixed;visibility:hidden;z-index:1000}.g-modal__content-aligner{align-items:center;display:inline-flex;justify-content:center;min-height:100%;min-width:100%}.g-modal__content-wrapper{margin:var(--g-modal-margin,20px);overflow-x:hidden}.g-modal__content,.g-modal__content-wrapper{border-radius:var(--g-modal-border-radius,5px)}.g-modal__content{background-color:var(--g-color-base-modal)}.g-modal__content_has-scroll{max-height:calc(100vh - var(--g-modal-margin, 20px)*2);overflow-y:auto}.g-modal,.g-modal__content{animation-fill-mode:forwards;animation-timing-function:ease-out;outline:none}.g-modal_exit_active,.g-modal_open{display:block;margin:0;visibility:visible}.g-modal_appear_active,.g-modal_enter_active{animation-duration:.15s;animation-name:g-modal-open}.g-modal_appear_active .g-modal__content,.g-modal_enter_active .g-modal__content{animation-duration:.15s;animation-name:g-modal-content-open}.g-modal_exit_active{animation-duration:.2s;animation-name:g-modal}@keyframes g-modal{0%{opacity:1}to{opacity:0}}@keyframes g-modal-open{0%{opacity:0}to{opacity:1}}@keyframes g-modal-content-open{0%{transform:scale(.75)}to{transform:scale(1)}}.tablet-icon{border:1px solid;border-radius:4px;display:flex;font-size:10px;height:16px;justify-content:center;text-transform:uppercase;width:23px}.tablet-icon__type{line-height:14px}.header{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:flex;flex:0 0 40px;justify-content:space-between;padding:0 20px 0 12px}.header__breadcrumbs-item{color:var(--g-color-text-secondary);display:flex;gap:3px}.header__breadcrumbs-item_link:hover{color:var(--g-color-text-complementary)}.header__breadcrumbs-item_active{color:var(--g-color-text-primary)}.header__breadcrumbs-icon{align-items:center;display:flex}.g-divider{--_--content-gap:8px;--_--size:1px}.g-divider:not(:empty){align-items:center;border:none;display:flex}.g-divider:not(:empty):after,.g-divider:not(:empty):before{content:""}.g-divider:after,.g-divider:before{background:var(--g-divider-color,var(--g-color-line-generic));flex-grow:1}.g-divider_orientation_vertical{border-inline-start:1px solid var(--g-divider-color,var(--g-color-line-generic));flex-direction:column}.g-divider_orientation_vertical:after,.g-divider_orientation_vertical:before{width:var(--_--size)}.g-divider_orientation_vertical:before{margin-block-end:var(--_--content-gap)}.g-divider_orientation_vertical:after{margin-block-start:var(--_--content-gap)}.g-divider_orientation_horizontal{border-block-start:1px solid var(--g-divider-color,var(--g-color-line-generic))}.g-divider_orientation_horizontal:after,.g-divider_orientation_horizontal:before{height:var(--_--size)}.g-divider_orientation_horizontal:before{margin-inline-end:var(--_--content-gap)}.g-divider_orientation_horizontal:after{margin-inline-start:var(--_--content-gap)}.g-divider_align_end:after,.g-divider_align_start:before{display:none}.g-menu{background-color:var(--g-color-base-float);box-sizing:border-box;color:var(--g-color-text-primary);display:block;font-size:var(--g-text-body-1-font-size);list-style:none;margin:0;outline:none;overflow:hidden auto;padding:0;-webkit-user-select:none;user-select:none}.g-menu__list-group-item+.g-menu__list-group-item,.g-menu__list-group-item+.g-menu__list-item,.g-menu__list-item+.g-menu__list-group-item{border-block-start:1px solid var(--g-color-line-generic)}.g-menu__item{-webkit-tap-highlight-color:rgba(0,0,0,0);align-items:center;color:var(--g-color-text-primary);display:flex;outline:none;text-decoration:none;touch-action:manipulation}.g-menu__item-icon{display:flex}.g-menu__item-icon-end{display:flex;margin-inline-end:0}.g-menu__item-content{flex-grow:1;min-width:0}.g-menu__item_interactive{cursor:pointer}.g-menu__item_interactive:focus-visible,.g-menu__item_interactive:hover,.g-menu__item_selected{background-color:var(--g-color-base-simple-hover)}.g-menu__item_disabled{color:var(--g-color-text-secondary);cursor:default;pointer-events:none}.g-menu__item_disabled:hover{background-color:initial}.g-menu__item_active{background-color:var(--g-color-base-selection);cursor:default}.g-menu__item_active:focus-visible,.g-menu__item_active:hover{background-color:var(--g-color-base-selection-hover)}.g-menu__item_theme_danger:not(.g-menu__item_disabled){color:var(--g-color-text-danger)}.g-menu__group-label{color:var(--g-color-text-hint);font-weight:var(--g-text-accent-font-weight)}.g-menu__group-list{list-style:none;margin:0;padding:0}.g-menu_size_s{line-height:24px;padding:3px 0}.g-menu_size_s .g-menu__group-label,.g-menu_size_s .g-menu__item{padding:0 10px}.g-menu_size_s .g-menu__item-icon{margin-inline-end:3px}.g-menu_size_s .g-menu__item-icon-end{margin-inline-start:3px}.g-menu_size_s .g-menu__list-group-item+.g-menu__list-group-item,.g-menu_size_s .g-menu__list-group-item+.g-menu__list-item,.g-menu_size_s .g-menu__list-item+.g-menu__list-group-item{margin-block-start:3px;padding-block-start:3px}.g-menu_size_m{line-height:24px;padding:4px 0}.g-menu_size_m .g-menu__group-label,.g-menu_size_m .g-menu__item{padding:0 13px}.g-menu_size_m .g-menu__item-icon{margin-inline-end:4px}.g-menu_size_m .g-menu__item-icon-end{margin-inline-start:4px}.g-menu_size_m .g-menu__list-group-item+.g-menu__list-group-item,.g-menu_size_m .g-menu__list-group-item+.g-menu__list-item,.g-menu_size_m .g-menu__list-item+.g-menu__list-group-item{margin-block-start:4px;padding-block-start:4px}.g-menu_size_l{line-height:28px;padding:5px 0}.g-menu_size_l .g-menu__group-label,.g-menu_size_l .g-menu__item{padding:0 15px}.g-menu_size_l .g-menu__item-icon{margin-inline-end:5px}.g-menu_size_l .g-menu__item-icon-end{margin-inline-start:5px}.g-menu_size_l .g-menu__list-group-item+.g-menu__list-group-item,.g-menu_size_l .g-menu__list-group-item+.g-menu__list-item,.g-menu_size_l .g-menu__list-item+.g-menu__list-group-item{margin-block-start:5px;padding-block-start:5px}.g-menu_size_xl{font-size:var(--g-text-body-2-font-size);line-height:36px;padding:6px 0}.g-menu_size_xl .g-menu__group-label,.g-menu_size_xl .g-menu__item{padding:0 15px}.g-menu_size_xl .g-menu__item-icon{margin-inline-end:6px}.g-menu_size_xl .g-menu__item-icon-end{margin-inline-start:6px}.g-menu_size_xl .g-menu__list-group-item:not(:first-child){margin-block-start:6px;padding-block-start:6px}.g-menu_size_xl .g-menu__list-group-item:not(:last-child){margin-block-end:6px;padding-block-end:6px}.g-dropdown-menu__switcher-wrapper{display:inline-block}.g-dropdown-menu__switcher-button{display:flex}.g-dropdown-menu__menu-item_separator{border-block-start:1px solid var(--g-color-line-generic-solid);margin:.5em 0;pointer-events:none}.g-dropdown-menu__sub-menu-arrow{inset-inline-end:-4px;position:relative}.g-dropdown-menu__sub-menu{position:relative}.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:after,.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:before{content:"";height:100%;inset-block-start:0;position:absolute;width:10px}.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:before{inset-inline-start:-10px}.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:after{inset-inline-end:-10px}.g-breadcrumbs__inner{align-items:center;display:inline-flex;gap:4px;min-height:24px;overflow:hidden;width:100%}.g-breadcrumbs__switcher{background:none;border:none;color:inherit;color:var(--g-color-text-secondary);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.g-breadcrumbs__switcher:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-breadcrumbs__item,.g-breadcrumbs__switcher{display:inline-block;flex-shrink:1;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-breadcrumbs__item:focus-visible,.g-breadcrumbs__switcher:focus-visible{border-radius:var(--g-focus-border-radius);outline:2px solid var(--g-color-line-focus)}.g-breadcrumbs_calculated_no .g-breadcrumbs__item{overflow:visible}.g-breadcrumbs__divider{align-items:center;color:var(--g-color-text-secondary);display:flex}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item .g-menu__item{padding-inline-start:80px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(0) .g-menu__item{padding-inline-start:0!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:first-child .g-menu__item{padding-inline-start:8px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(2) .g-menu__item{padding-inline-start:16px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(3) .g-menu__item{padding-inline-start:24px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(4) .g-menu__item{padding-inline-start:32px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(5) .g-menu__item{padding-inline-start:40px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(6) .g-menu__item{padding-inline-start:48px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(7) .g-menu__item{padding-inline-start:56px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(8) .g-menu__item{padding-inline-start:64px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(9) .g-menu__item{padding-inline-start:72px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(10) .g-menu__item{padding-inline-start:80px!important}*{font-feature-settings:"tnum";box-sizing:border-box;font-variant-numeric:tabular-nums}.g-select-popup__tick-icon{box-sizing:initial}#root,body,html{box-sizing:border-box;height:100%;margin:0;overflow:auto;padding:0}:root{--g-color-base-yellow-light:#ffc70026;--g-color-base-yellow-medium:#ffdb4d66;--tenant-object-info-max-value-width:300px;--diagnostics-section-title-margin:20px;--diagnostics-section-margin:30px;--diagnostics-section-table-width:872px}.g-root{--ydb-data-table-color-hover:var(--g-color-base-simple-hover-solid);--ydb-color-status-grey:var(--g-color-base-neutral-heavy);--ydb-color-status-green:var(--g-color-base-positive-heavy);--ydb-color-status-yellow:var(--g-color-base-warning-heavy);--ydb-color-status-orange:var(--g-color-private-orange-500-solid);--ydb-color-status-red:var(--g-color-base-danger-heavy);--ydb-color-status-blue:var(--g-color-base-info-heavy);--ydb-color-status-black:var(--g-color-base-misc-heavy);--g-popover-max-width:500px}.g-root_theme_light,.g-root_theme_light-hc{--code-background-color:var(--g-color-base-simple-hover)}.g-root_theme_dark,.g-root_theme_dark-hc{--code-background-color:#1e1e1e}:is(#tab,.g-tabs-item_active .g-tabs-item__title){color:var(--g-color-text-primary)!important}:is(#tab,.g-tabs-item__title){color:var(--g-color-text-secondary)}.gn-aside-header__pane-container{height:100%}.gn-aside-header__content{display:flex;flex-direction:column;height:100%;overflow:auto;position:relative}.loader{align-items:center;display:flex;justify-content:center;left:50%;position:fixed;top:50%;z-index:99999999}.app{--data-table-row-height:40px;--data-table-cell-align:middle;--data-table-head-align:middle;display:flex;flex:1 1 auto;flex-direction:column;height:100%}.app .data-table{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.app .data-table__td,.app .data-table__th{border-left:unset;border-right:unset;border-top:unset;height:var(--data-table-row-height)}.app .data-table__th{font-weight:700}.app .data-table__table{border-collapse:initial;border-spacing:0}.app .data-table__box_sticky-head_moving .data-table__th{height:unset}.app__main{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.error{color:var(--g-color-text-danger)}.g-root .data-table_highlight-rows .data-table__row:hover{background:var(--ydb-data-table-color-hover)}.g-table-column-setup__item{cursor:pointer!important;padding:0 8px 0 32px!important}.app_embedded{font-family:Rubik,sans-serif}.g-list{--_--item-padding:var(--g-list-item-padding,0);display:flex;flex:1 1 auto;flex-direction:column;outline:none;width:100%}.g-list__filter{flex:0 0 auto;margin-block-end:8px;padding:var(--_--item-padding)}.g-list__items{flex:1 1 auto}.g-list__empty-placeholder,.g-list__item{align-items:center;box-sizing:border-box;display:flex;overflow:hidden;padding:var(--_--item-padding);-webkit-user-select:none;user-select:none}.g-list__item_active{background:var(--g-color-base-simple-hover)}.g-list__item_selected{background:var(--g-color-base-selection)}.g-list__item_selected:hover{background:var(--g-color-base-selection-hover)}.g-list__item_sort-handle-align_right{flex-direction:row-reverse}.g-list__item_sort-handle-align_right .g-list__item-sort-icon{margin-inline:10px 0}.g-list__item_sortable[data-rbd-drag-handle-context-id]:active{cursor:grabbing}.g-list__item_dragging{background:var(--g-color-base-simple-hover-solid);z-index:100001}.g-list__empty-placeholder{box-sizing:border-box;color:var(--g-color-text-hint);min-height:36px;padding-block:8px}.g-list__item-content{align-items:center;display:flex;flex:1 1 auto;height:100%;overflow:hidden;text-overflow:ellipsis}.g-list__item-sort-icon{align-items:center;color:var(--g-color-text-hint);display:flex;flex:0 0 auto;margin-inline-end:4px;width:12px}.g-list__loading-indicator{align-items:center;display:flex;justify-content:center;width:100%}:root{--information-popup-padding:16px;--information-popup-header-padding:16px}.information-popup__content{box-sizing:border-box;display:flex;flex-direction:column;padding:var(--information-popup-header-padding) 0 0 0;position:relative;width:280px}.information-popup__docs,.information-popup__footer{display:flex;flex-direction:column;flex-shrink:0}.information-popup__docs{padding-bottom:8px}.information-popup__footer{background-color:var(--g-color-base-generic);border-top:1px solid var(--g-color-line-generic);padding:12px 0 8px;position:relative}.information-popup__title{flex-shrink:0;margin-bottom:4px;padding:4px var(--information-popup-padding)}.information-popup__docs-list-wrap{display:flex;flex-direction:column;flex-shrink:0;margin-bottom:12px}.information-popup__docs-list-wrap:last-child{margin-bottom:0}.information-popup__docs-link,.information-popup__shortcuts-item{align-items:center;box-sizing:border-box;cursor:pointer;display:flex;flex-grow:1;height:100%;line-height:var(--g-text-body-1-line-height);padding:8px var(--information-popup-padding);width:100%}.information-popup__docs-link:hover,.information-popup__shortcuts-item:hover{background-color:var(--g-color-base-simple-hover)}.information-popup__shortcuts-item{justify-content:space-between}.information-popup__docs-link,.information-popup__docs-link:active,.information-popup__docs-link:focus,.information-popup__docs-link:hover,.information-popup__docs-link:visited{color:inherit;outline:none;text-decoration:none}.information-popup__item-icon-wrap{height:16px;margin-right:10px;width:16px}.information-popup__shortcuts-content,.kv-navigation__internal-user{align-items:center;display:flex}.kv-navigation__internal-user{justify-content:space-between;line-height:var(--g-text-body-2-line-height);margin-left:16px}.kv-navigation__user-info-wrapper{display:flex;flex-direction:column}.kv-navigation__ydb-internal-user-title{font-weight:500}.kv-navigation__ydb-user-wrapper{padding:10px;width:300px}.kv-navigation__hotkeys-panel-title{display:flex;gap:var(--g-spacing-2)}.ydb-resizeable-data-table{display:flex;padding-right:20px;width:max-content}.ydb-resizeable-data-table__row-skeleton{height:50%;width:100%}.ydb-resizeable-data-table__row-skeleton:after{animation:none!important}.g-skeleton{--_--animation-from:calc(-100%*var(--g-flow-direction));--_--animation-to:calc(100%*var(--g-flow-direction));--_--gradient-deg:calc(90deg*var(--g-flow-direction));background-color:var(--g-color-base-generic);border-radius:5px;display:inline-block;overflow:hidden;position:relative;width:100%;z-index:0}.g-skeleton:after{animation:g-skeleton 1.2s ease-out infinite;background-image:linear-gradient(var(--_--gradient-deg),#0000,var(--g-color-base-generic));content:"";inset:0;position:absolute}@keyframes g-skeleton{0%{transform:translateX(var(--_--animation-from))}to{transform:translateX(var(--_--animation-to))}}.ydb-status-icon__status-color_state_green{background-color:var(--ydb-color-status-green)}.ydb-status-icon__status-color_state_yellow{background-color:var(--ydb-color-status-yellow)}.ydb-status-icon__status-color_state_blue{background-color:var(--ydb-color-status-blue)}.ydb-status-icon__status-color_state_red{background-color:var(--ydb-color-status-red)}.ydb-status-icon__status-color_state_grey{background-color:var(--ydb-color-status-grey)}.ydb-status-icon__status-color_state_orange{background-color:var(--ydb-color-status-orange)}.ydb-status-icon__status-icon_state_grey{color:var(--ydb-color-status-grey)}.ydb-status-icon__status-icon_state_green{color:var(--ydb-color-status-green)}.ydb-status-icon__status-icon_state_blue{color:var(--ydb-color-status-blue)}.ydb-status-icon__status-icon_state_yellow{color:var(--ydb-color-status-yellow)}.ydb-status-icon__status-icon_state_orange{color:var(--ydb-color-status-orange)}.ydb-status-icon__status-icon_state_red{color:var(--ydb-color-status-red)}.ydb-status-icon__status-color,.ydb-status-icon__status-icon{border-radius:3px;display:inline-flex;flex-shrink:0}.ydb-status-icon__status-color_size_xs,.ydb-status-icon__status-icon_size_xs{aspect-ratio:1;height:12px;width:12px}.ydb-status-icon__status-color_size_s,.ydb-status-icon__status-icon_size_s{aspect-ratio:1;height:16px;width:16px}.ydb-status-icon__status-color_size_m,.ydb-status-icon__status-icon_size_m{aspect-ratio:1;height:18px;width:18px}.ydb-status-icon__status-color_size_l,.ydb-status-icon__status-icon_size_l{height:24px;width:24px}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}.entity-status{--button-width:28px;align-items:center;display:inline-flex;font-size:var(--g-text-body-2-font-size);height:100%;line-height:var(--g-text-body-2-line-height);max-width:100%;position:relative}.entity-status__icon{margin-right:var(--g-spacing-2)}.entity-status__clipboard-button,.entity-status__info-icon{color:var(--g-color-text-secondary);opacity:0}.entity-status__clipboard-button:focus-visible,.entity-status__clipboard-button_visible,.entity-status__info-icon:focus-visible,.entity-status__info-icon_visible{opacity:1}.entity-status__clipboard-button:focus-visible,.entity-status__info-icon:focus-visible{background-color:var(--g-color-base-float);position:absolute;right:2px;top:2px}.data-table__row:hover .entity-status__clipboard-button,.data-table__row:hover .entity-status__info-icon,.ydb-paginated-table__row:hover .entity-status__clipboard-button,.ydb-paginated-table__row:hover .entity-status__info-icon{opacity:1}.data-table__row:hover .entity-status__clipboard-button:focus-visible,.data-table__row:hover .entity-status__info-icon:focus-visible,.ydb-paginated-table__row:hover .entity-status__clipboard-button:focus-visible,.ydb-paginated-table__row:hover .entity-status__info-icon:focus-visible{background-color:unset;position:static}.entity-status__clipboard-button_visible,.entity-status__info-icon_visible{opacity:1}.entity-status__info-icon:hover{color:var(--g-color-text-primary)}.entity-status__wrapper{overflow:hidden;position:relative}.entity-status__wrapper_with-clipboard-button,.entity-status__wrapper_with-info-button{padding-right:var(--button-width)}.entity-status__wrapper_with-clipboard-button.entity-status__wrapper_with-info-button{padding-right:calc(var(--button-width)*2)}.entity-status__controls-wrapper{align-items:center;display:flex;gap:var(--g-spacing-1);height:100%;position:absolute;right:0;top:0;width:0}.entity-status__controls-wrapper_visible{background-color:var(--g-color-base-background);padding:var(--g-spacing-1);width:min-content}.data-table__row:hover .entity-status__controls-wrapper,.ydb-paginated-table__row:hover .entity-status__controls-wrapper,.ydb-tree-view__item .entity-status__controls-wrapper{background-color:var(--ydb-data-table-color-hover);padding:var(--g-spacing-1);width:min-content}.entity-status__label{color:var(--g-color-text-complementary);font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);margin-right:2px}.entity-status__label_size_l{font-size:var(--g-text-header-2-font-size)}.entity-status__link{display:inline-block;margin-top:5px;overflow:hidden;text-overflow:ellipsis;white-space:nowrap;width:100%}.entity-status__wrapper_with-clipboard-button .entity-status__link,.entity-status__wrapper_with-info-button .entity-status__link{width:calc(100% + var(--button-width))}.entity-status__wrapper_with-clipboard-button.entity-status__wrapper_with-info-button .entity-status__link{width:calc(100% + var(--button-width)*2)}.entity-status__link_with-left-trim{direction:rtl;text-align:end}.entity-status__link_with-left-trim .entity-status__name{unicode-bidi:plaintext}.entity-status__label_state_blue{color:var(--ydb-color-status-blue)}.entity-status__label_state_yellow{color:var(--ydb-color-status-yellow)}.entity-status__label_state_orange{color:var(--ydb-color-status-orange)}.entity-status__label_state_red{color:var(--ydb-color-status-red)}.ydb-usage-label_overload{background-color:var(--ydb-color-status-red);color:var(--g-color-text-light-primary)}.extended-cluster{display:flex;height:100%}.extended-cluster__balancer{align-items:center;display:flex;flex-direction:row}.extended-cluster__clipboard-button{margin-left:5px}.g-toast{--_--item-gap:10px;--_--item-padding:16px;--_--background-color:var(--g-color-base-background);background-color:var(--_--background-color);border-radius:8px;box-shadow:0 0 15px var(--g-color-sfx-shadow);box-sizing:border-box;display:flex;font-size:var(--g-text-body-2-font-size);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));overflow:hidden;padding:var(--g-toaster-item-padding,var(--_--item-padding));position:relative;width:inherit;z-index:0}.g-toast_mobile{width:100%}.g-toast_theme_normal{--_--background-color:var(--g-color-base-float)}.g-toast_theme_info{--_--container-background-color:var(--g-color-base-info-light);--_--icon-color:var(--g-color-text-info-heavy)}.g-toast_theme_success{--_--container-background-color:var(--g-color-base-positive-light);--_--icon-color:var(--g-color-text-positive-heavy)}.g-toast_theme_warning{--_--container-background-color:var(--g-color-base-warning-light);--_--icon-color:var(--g-color-text-warning-heavy)}.g-toast_theme_danger{--_--container-background-color:var(--g-color-base-danger-light);--_--icon-color:var(--g-color-text-danger-heavy)}.g-toast_theme_utility{--_--container-background-color:var(--g-color-base-utility-light);--_--icon-color:var(--g-color-text-utility-heavy)}.g-toast__container{display:flex;flex:1 1 auto;flex-flow:column nowrap;min-height:var(--g-text-body-2-line-height);min-width:0}.g-toast__container:before{background-color:var(--_--container-background-color);content:"";height:100%;inset-block-start:0;inset-inline-start:0;pointer-events:none;position:absolute;width:100%;z-index:-1}.g-toast__icon-container{color:var(--_--icon-color);flex:0 0 auto;min-width:0;padding-block-start:2px;padding-inline-end:8px}.g-toast__title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height);margin:0;padding-inline-end:32px}.g-toast__content{margin-block-start:var(--g-spacing-2)}.g-toast__content_without-title{margin-block-start:0;padding-inline-end:32px}.g-toast__actions{margin-block-start:var(--g-spacing-3)}.g-toast__action{margin-inline-end:8px}.g-toast .g-toast__btn-close{inset-block-start:16px;inset-inline-end:16px;position:absolute}.g-toast-animation-mobile_enter{opacity:0;position:absolute}.g-toast-animation-mobile_enter_active{animation:g-toast-enter-mobile .6s ease-out forwards;position:relative}.g-toast-animation-mobile_exit_active{animation:g-toast-exit-mobile .6s ease-in forwards}@keyframes g-toast-enter-mobile{0%{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateY(10px)}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateY(10px)}to{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}}@keyframes g-toast-exit-mobile{0%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateY(10px)}to{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateY(10px)}}.g-toast-animation-desktop_enter{opacity:0;position:absolute}.g-toast-animation-desktop_enter_active{animation:g-toast-enter-desktop .6s ease-out forwards;position:relative}.g-toast-animation-desktop_exit_active{animation:g-toast-exit-desktop .6s ease-in forwards}@keyframes g-toast-enter-desktop{0%{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateX(calc(var(--g-flow-direction)*10px))}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(calc(var(--g-flow-direction)*10px))}to{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}}@keyframes g-toast-exit-desktop{0%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(calc(var(--g-flow-direction)*10px))}to{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateX(calc(var(--g-flow-direction)*10px))}}.g-toaster{--_--width:312px;align-items:flex-end;display:flex;flex-direction:column;inset-block-end:0;inset-inline-end:10px;position:fixed;width:var(--g-toaster-width,var(--_--width));z-index:100000}.g-toaster_mobile{--_--width:calc(100% - 20px);inset-inline-start:50%;transform:translate(-50%)}.g-root{--g-font-family-sans:"Inter","Helvetica Neue","Helvetica","Arial",sans-serif;--g-font-family-monospace:"Menlo","Monaco","Consolas","Ubuntu Mono","Liberation Mono","DejaVu Sans Mono","Courier New","Courier",monospace;--g-text-body-font-family:var(--g-font-family-sans);--g-text-caption-font-family:var(--g-font-family-sans);--g-text-header-font-family:var(--g-font-family-sans);--g-text-subheader-font-family:var(--g-font-family-sans);--g-text-display-font-family:var(--g-font-family-sans);--g-text-code-font-family:var(--g-font-family-monospace);--g-text-body-font-weight:400;--g-text-caption-font-weight:400;--g-text-header-font-weight:600;--g-text-display-font-weight:600;--g-text-code-font-weight:400;--g-text-accent-font-weight:600;--g-text-body-1-font-size:13px;--g-text-body-1-line-height:18px;--g-text-body-2-font-size:15px;--g-text-body-2-line-height:20px;--g-text-body-3-font-size:17px;--g-text-body-3-line-height:24px;--g-text-body-short-font-size:13px;--g-text-body-short-line-height:16px;--g-text-caption-1-font-size:9px;--g-text-caption-1-line-height:12px;--g-text-caption-2-font-size:11px;--g-text-caption-2-line-height:16px;--g-text-header-1-font-size:20px;--g-text-header-1-line-height:24px;--g-text-header-2-font-size:24px;--g-text-header-2-line-height:28px;--g-text-subheader-1-font-size:13px;--g-text-subheader-1-line-height:18px;--g-text-subheader-2-font-size:15px;--g-text-subheader-2-line-height:20px;--g-text-subheader-3-font-size:17px;--g-text-subheader-3-line-height:24px;--g-text-display-1-font-size:28px;--g-text-display-1-line-height:36px;--g-text-display-2-font-size:32px;--g-text-display-2-line-height:40px;--g-text-display-3-font-size:40px;--g-text-display-3-line-height:48px;--g-text-display-4-font-size:48px;--g-text-display-4-line-height:52px;--g-text-code-1-font-size:12px;--g-text-code-1-line-height:18px;--g-text-code-2-font-size:14px;--g-text-code-2-line-height:20px;--g-text-code-3-font-size:16px;--g-text-code-3-line-height:24px;--g-text-code-inline-1-font-size:12px;--g-text-code-inline-1-line-height:14px;--g-text-code-inline-2-font-size:14px;--g-text-code-inline-2-line-height:16px;--g-text-code-inline-3-font-size:16px;--g-text-code-inline-3-line-height:20px;--g-spacing-base:4px;--g-spacing-0:calc(var(--g-spacing-base)*0);--g-spacing-half:calc(var(--g-spacing-base)*0.5);--g-spacing-1:var(--g-spacing-base);--g-spacing-2:calc(var(--g-spacing-base)*2);--g-spacing-3:calc(var(--g-spacing-base)*3);--g-spacing-4:calc(var(--g-spacing-base)*4);--g-spacing-5:calc(var(--g-spacing-base)*5);--g-spacing-6:calc(var(--g-spacing-base)*6);--g-spacing-7:calc(var(--g-spacing-base)*7);--g-spacing-8:calc(var(--g-spacing-base)*8);--g-spacing-9:calc(var(--g-spacing-base)*9);--g-spacing-10:calc(var(--g-spacing-base)*10);--g-scrollbar-width:12px;--g-border-radius-xs:3px;--g-border-radius-s:5px;--g-border-radius-m:6px;--g-border-radius-l:8px;--g-border-radius-xl:10px;--g-focus-border-radius:2px;background:var(--g-color-base-background);color:var(--g-color-text-primary);font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-root[dir=ltr],body.g-root{--g-flow-direction:1;--g-flow-is-ltr:1;--g-flow-is-rtl:0}.g-root[dir=rtl]{--g-flow-direction:-1;--g-flow-is-ltr:0;--g-flow-is-rtl:1}.g-root_theme_light{--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#ebf5fe;--g-color-private-blue-100-solid:#e1effd;--g-color-private-blue-150-solid:#d7eafc;--g-color-private-blue-200-solid:#c3e0fb;--g-color-private-blue-250-solid:#afd5f9;--g-color-private-blue-300-solid:#9bcbf8;--g-color-private-blue-350-solid:#86c1f7;--g-color-private-blue-400-solid:#72b6f5;--g-color-private-blue-450-solid:#5eacf4;--g-color-private-blue-500-solid:#4aa1f2;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#348bdc;--g-color-private-blue-650-solid:#327fc8;--g-color-private-blue-700-solid:#3072b3;--g-color-private-blue-750-solid:#2e669e;--g-color-private-blue-800-solid:#2c5a8a;--g-color-private-blue-850-solid:#2a4e75;--g-color-private-blue-900-solid:#284260;--g-color-private-blue-950-solid:#26354b;--g-color-private-blue-1000-solid:#252f41;--g-color-private-green-50:#32ba761a;--g-color-private-green-100:#32ba7626;--g-color-private-green-150:#32ba7633;--g-color-private-green-200:#32ba764d;--g-color-private-green-250:#32ba7666;--g-color-private-green-300:#32ba7680;--g-color-private-green-350:#32ba7699;--g-color-private-green-400:#32ba76b3;--g-color-private-green-450:#32ba76cc;--g-color-private-green-500:#32ba76e6;--g-color-private-green-50-solid:#ebf8f1;--g-color-private-green-100-solid:#e0f5ea;--g-color-private-green-150-solid:#d6f1e4;--g-color-private-green-200-solid:#c2ead6;--g-color-private-green-250-solid:#ade3c8;--g-color-private-green-300-solid:#9db;--g-color-private-green-350-solid:#84d6ad;--g-color-private-green-400-solid:#70cf9f;--g-color-private-green-450-solid:#5bc891;--g-color-private-green-500-solid:#47c184;--g-color-private-green-550-solid:#32ba76;--g-color-private-green-600-solid:#30aa6e;--g-color-private-green-650-solid:#2f9b65;--g-color-private-green-700-solid:#2d8b5d;--g-color-private-green-750-solid:#2c7b54;--g-color-private-green-800-solid:#2a6c4c;--g-color-private-green-850-solid:#285c44;--g-color-private-green-900-solid:#274c3b;--g-color-private-green-950-solid:#253c33;--g-color-private-green-1000-solid:#24352f;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#fff9ef;--g-color-private-yellow-100-solid:#fff5e7;--g-color-private-yellow-150-solid:#fff2de;--g-color-private-yellow-200-solid:#ffecce;--g-color-private-yellow-250-solid:#ffe5be;--g-color-private-yellow-300-solid:#ffdfae;--g-color-private-yellow-350-solid:#ffd89d;--g-color-private-yellow-400-solid:#ffd28d;--g-color-private-yellow-450-solid:#ffcb7d;--g-color-private-yellow-500-solid:#ffc56c;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#e9ae56;--g-color-private-yellow-650-solid:#d39e50;--g-color-private-yellow-700-solid:#bd8e4b;--g-color-private-yellow-750-solid:#a77e45;--g-color-private-yellow-800-solid:#916e3f;--g-color-private-yellow-850-solid:#7a5d39;--g-color-private-yellow-900-solid:#644d33;--g-color-private-yellow-950-solid:#4e3d2e;--g-color-private-yellow-1000-solid:#43352b;--g-color-private-orange-400-solid:#ffa04d;--g-color-private-orange-500-solid:#ff8519;--g-color-private-orange-600-solid:#e96e03;--g-color-private-orange-650-solid:#d36507;--g-color-private-orange-700-solid:#bd5c0a;--g-color-private-orange-750-solid:#a7530e;--g-color-private-orange-800-solid:#914a11;--g-color-private-orange-850-solid:#7a4114;--g-color-private-orange-900-solid:#643818;--g-color-private-orange-950-solid:#4e2f1b;--g-color-private-orange-1000-solid:#432b1d;--g-color-private-red-50:#ff003d1a;--g-color-private-red-100:#ff003d26;--g-color-private-red-150:#ff003d33;--g-color-private-red-200:#ff003d4d;--g-color-private-red-250:#ff003d66;--g-color-private-red-300:#ff003d80;--g-color-private-red-350:#ff003d99;--g-color-private-red-400:#ff003db3;--g-color-private-red-450:#ff003dcc;--g-color-private-red-500:#ff003de6;--g-color-private-red-50-solid:#ffe6ec;--g-color-private-red-100-solid:#ffd9e2;--g-color-private-red-150-solid:#ffccd8;--g-color-private-red-200-solid:#ffb3c5;--g-color-private-red-250-solid:#ff99b1;--g-color-private-red-300-solid:#ff809e;--g-color-private-red-350-solid:#ff668b;--g-color-private-red-400-solid:#ff4d77;--g-color-private-red-450-solid:#ff3364;--g-color-private-red-500-solid:#ff1950;--g-color-private-red-550-solid:#ff003d;--g-color-private-red-600-solid:#e9033a;--g-color-private-red-650-solid:#d30638;--g-color-private-red-700-solid:#bd0935;--g-color-private-red-750-solid:#a70c32;--g-color-private-red-800-solid:#910f30;--g-color-private-red-850-solid:#7a112d;--g-color-private-red-900-solid:#64142a;--g-color-private-red-950-solid:#4e1727;--g-color-private-red-1000-solid:#431926;--g-color-private-purple-600-solid:#844dbb;--g-color-private-purple-650-solid:#7947aa;--g-color-private-purple-700-solid:#6e4299;--g-color-private-purple-750-solid:#633d88;--g-color-private-purple-800-solid:#593877;--g-color-private-purple-850-solid:#4e3266;--g-color-private-purple-900-solid:#432d55;--g-color-private-purple-950-solid:#382844;--g-color-private-purple-1000-solid:#32253c;--g-color-private-cool-grey-300-solid:#b5c2cc;--g-color-private-cool-grey-600-solid:#647a8d;--g-color-private-cool-grey-650-solid:#5c6f81;--g-color-private-cool-grey-700-solid:#556575;--g-color-private-cool-grey-750-solid:#4e5b69;--g-color-private-cool-grey-800-solid:#47515e;--g-color-private-cool-grey-850-solid:#3f4652;--g-color-private-cool-grey-900-solid:#383c46;--g-color-private-cool-grey-950-solid:#31323a;--g-color-private-cool-grey-1000-solid:#2d2c34;--g-color-text-primary:var(--g-color-text-dark-primary);--g-color-text-complementary:var(--g-color-text-dark-complementary);--g-color-text-secondary:var(--g-color-text-dark-secondary);--g-color-text-hint:var(--g-color-text-dark-hint);--g-color-text-info:var(--g-color-private-blue-600-solid);--g-color-text-positive:var(--g-color-private-green-600-solid);--g-color-text-warning:var(--g-color-private-yellow-700-solid);--g-color-text-danger:var(--g-color-private-red-600-solid);--g-color-text-utility:var(--g-color-private-purple-600-solid);--g-color-text-misc:var(--g-color-private-cool-grey-600-solid);--g-color-text-info-heavy:var(--g-color-private-blue-700-solid);--g-color-text-positive-heavy:var(--g-color-private-green-700-solid);--g-color-text-warning-heavy:var(--g-color-private-orange-700-solid);--g-color-text-danger-heavy:var(--g-color-private-red-700-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-700-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-700-solid);--g-color-text-brand:var(--g-color-private-yellow-700-solid);--g-color-text-brand-heavy:var(--g-color-private-orange-700-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-650-solid);--g-color-text-link-hover:var(--g-color-private-orange-650-solid);--g-color-text-link-visited:var(--g-color-private-purple-550-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-800-solid);--g-color-text-dark-primary:var(--g-color-private-black-850);--g-color-text-dark-complementary:var(--g-color-private-black-700);--g-color-text-dark-secondary:var(--g-color-private-black-500);--g-color-text-dark-hint:var(--g-color-private-black-300);--g-color-text-light-primary:var(--g-color-private-white-1000-solid);--g-color-text-light-complementary:var(--g-color-private-white-850);--g-color-text-light-secondary:var(--g-color-private-white-700);--g-color-text-light-hint:var(--g-color-private-white-500);--g-color-text-inverted-primary:var(--g-color-text-light-primary);--g-color-text-inverted-complementary:var(--g-color-text-light-complementary);--g-color-text-inverted-secondary:var(--g-color-text-light-secondary);--g-color-text-inverted-hint:var(--g-color-text-light-hint);--g-color-base-background:var(--g-color-private-white-1000-solid);--g-color-base-generic:var(--g-color-private-black-50);--g-color-base-generic-hover:var(--g-color-private-black-150);--g-color-base-generic-medium:var(--g-color-private-black-150);--g-color-base-generic-medium-hover:var(--g-color-private-black-250);--g-color-base-generic-accent:var(--g-color-private-black-150);--g-color-base-generic-accent-disabled:var(--g-color-private-black-70);--g-color-base-generic-ultralight:var(--g-color-private-black-20-solid);--g-color-base-simple-hover:var(--g-color-private-black-50);--g-color-base-simple-hover-solid:var(--g-color-private-black-50-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-600-solid);--g-color-base-selection:var(--g-color-private-yellow-200);--g-color-base-selection-hover:var(--g-color-private-yellow-300);--g-color-base-info-light:var(--g-color-private-blue-100);--g-color-base-info-light-hover:var(--g-color-private-blue-200);--g-color-base-info-medium:var(--g-color-private-blue-200);--g-color-base-info-medium-hover:var(--g-color-private-blue-300);--g-color-base-info-heavy:var(--g-color-private-blue-600-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-700-solid);--g-color-base-positive-light:var(--g-color-private-green-100);--g-color-base-positive-light-hover:var(--g-color-private-green-200);--g-color-base-positive-medium:var(--g-color-private-green-200);--g-color-base-positive-medium-hover:var(--g-color-private-green-300);--g-color-base-positive-heavy:var(--g-color-private-green-600-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-700-solid);--g-color-base-warning-light:var(--g-color-private-yellow-200);--g-color-base-warning-light-hover:var(--g-color-private-yellow-300);--g-color-base-warning-medium:var(--g-color-private-yellow-400);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-500);--g-color-base-warning-heavy:var(--g-color-private-yellow-550-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-650-solid);--g-color-base-danger-light:var(--g-color-private-red-100);--g-color-base-danger-light-hover:var(--g-color-private-red-200);--g-color-base-danger-medium:var(--g-color-private-red-200);--g-color-base-danger-medium-hover:var(--g-color-private-red-300);--g-color-base-danger-heavy:var(--g-color-private-red-600-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-700-solid);--g-color-base-utility-light:var(--g-color-private-purple-100);--g-color-base-utility-light-hover:var(--g-color-private-purple-200);--g-color-base-utility-medium:var(--g-color-private-purple-200);--g-color-base-utility-medium-hover:var(--g-color-private-purple-300);--g-color-base-utility-heavy:var(--g-color-private-purple-600-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-700-solid);--g-color-base-neutral-light:var(--g-color-private-black-50);--g-color-base-neutral-light-hover:var(--g-color-private-black-100);--g-color-base-neutral-medium:var(--g-color-private-black-200);--g-color-base-neutral-medium-hover:var(--g-color-private-black-250);--g-color-base-neutral-heavy:var(--g-color-private-black-450);--g-color-base-neutral-heavy-hover:var(--g-color-private-black-550);--g-color-base-misc-light:var(--g-color-private-cool-grey-100);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-200);--g-color-base-misc-medium:var(--g-color-private-cool-grey-200);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-300);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-600-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-700-solid);--g-color-base-light:var(--g-color-private-white-1000-solid);--g-color-base-light-hover:var(--g-color-private-white-850);--g-color-base-light-simple-hover:var(--g-color-private-white-150);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-1000-solid);--g-color-base-float-hover:var(--g-color-private-black-50-solid);--g-color-base-float-medium:var(--g-color-private-black-550-solid);--g-color-base-float-heavy:var(--g-color-private-black-700-solid);--g-color-base-float-accent:var(--g-color-private-white-1000-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-850);--g-color-base-float-announcement:var(--g-color-private-cool-grey-50-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-black-100);--g-color-line-generic-hover:var(--g-color-private-black-150);--g-color-line-generic-active:var(--g-color-private-black-300);--g-color-line-generic-accent:var(--g-color-private-black-150);--g-color-line-generic-accent-hover:var(--g-color-private-black-300);--g-color-line-generic-solid:var(--g-color-private-black-100-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-450);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-450);--g-color-line-positive:var(--g-color-private-green-450);--g-color-line-warning:var(--g-color-private-yellow-600-solid);--g-color-line-danger:var(--g-color-private-red-450);--g-color-line-utility:var(--g-color-private-purple-450);--g-color-line-misc:var(--g-color-private-cool-grey-450);--g-color-sfx-veil:var(--g-color-private-black-250);--g-color-sfx-shadow:var(--g-color-private-black-150);--g-color-sfx-shadow-heavy:var(--g-color-private-black-500);--g-color-sfx-shadow-light:var(--g-color-private-black-50);--g-color-sfx-fade:var(--g-color-private-white-300);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-black-100);--g-color-scroll-handle-hover:var(--g-color-private-black-150);--g-color-scroll-corner:var(--g-color-private-black-100);--g-color-infographics-axis:var(--g-color-private-black-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-950)}.g-root_theme_dark{--g-color-private-white-20-solid:#262226;--g-color-private-white-50-solid:#2d282d;--g-color-private-white-70-solid:#312d31;--g-color-private-white-100-solid:#383438;--g-color-private-white-150-solid:#433f43;--g-color-private-white-200-solid:#4e4a4e;--g-color-private-white-250-solid:#595559;--g-color-private-white-300-solid:#646164;--g-color-private-white-350-solid:#6f6c6f;--g-color-private-white-400-solid:#7a777a;--g-color-private-white-450-solid:#858385;--g-color-private-white-500-solid:#908e90;--g-color-private-white-550-solid:#9c999c;--g-color-private-white-600-solid:#a7a5a7;--g-color-private-white-650-solid:#b2b0b2;--g-color-private-white-700-solid:#bdbbbd;--g-color-private-white-750-solid:#c8c6c8;--g-color-private-white-800-solid:#d3d2d3;--g-color-private-white-850-solid:#deddde;--g-color-private-white-900-solid:#e9e8e9;--g-color-private-white-950-solid:#f4f4f4;--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#242937;--g-color-private-blue-100-solid:#252f41;--g-color-private-blue-150-solid:#26354b;--g-color-private-blue-200-solid:#284260;--g-color-private-blue-250-solid:#2a4e75;--g-color-private-blue-300-solid:#2c5a8a;--g-color-private-blue-350-solid:#2e669e;--g-color-private-blue-400-solid:#3072b3;--g-color-private-blue-450-solid:#327fc8;--g-color-private-blue-500-solid:#348bdc;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#4aa1f2;--g-color-private-blue-650-solid:#5eacf4;--g-color-private-blue-700-solid:#72b6f5;--g-color-private-blue-750-solid:#86c1f7;--g-color-private-blue-800-solid:#9bcbf8;--g-color-private-blue-850-solid:#afd5f9;--g-color-private-blue-900-solid:#c3e0fb;--g-color-private-blue-950-solid:#d7eafc;--g-color-private-blue-1000-solid:#e1effd;--g-color-private-green-50:#4db09b1a;--g-color-private-green-100:#4db09b26;--g-color-private-green-150:#4db09b33;--g-color-private-green-200:#4db09b4d;--g-color-private-green-250:#4db09b66;--g-color-private-green-300:#4db09b80;--g-color-private-green-350:#4db09b99;--g-color-private-green-400:#4db09bb3;--g-color-private-green-450:#4db09bcc;--g-color-private-green-500:#4db09be6;--g-color-private-green-50-solid:#262c2e;--g-color-private-green-100-solid:#283334;--g-color-private-green-150-solid:#2b3a3a;--g-color-private-green-200-solid:#2f4946;--g-color-private-green-250-solid:#335852;--g-color-private-green-300-solid:#38675f;--g-color-private-green-350-solid:#3c756b;--g-color-private-green-400-solid:#408477;--g-color-private-green-450-solid:#449383;--g-color-private-green-500-solid:#49a18f;--g-color-private-green-550-solid:#4db09b;--g-color-private-green-600-solid:#5fb8a5;--g-color-private-green-650-solid:#71c0af;--g-color-private-green-700-solid:#82c8b9;--g-color-private-green-750-solid:#94d0c3;--g-color-private-green-800-solid:#a6d8cd;--g-color-private-green-850-solid:#b8dfd7;--g-color-private-green-900-solid:#cae7e1;--g-color-private-green-950-solid:#dbefeb;--g-color-private-green-1000-solid:#e4f3f0;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#382d28;--g-color-private-yellow-100-solid:#43352b;--g-color-private-yellow-150-solid:#4e3d2e;--g-color-private-yellow-200-solid:#644d33;--g-color-private-yellow-250-solid:#7a5d39;--g-color-private-yellow-300-solid:#916e3f;--g-color-private-yellow-350-solid:#a77e45;--g-color-private-yellow-400-solid:#bd8e4b;--g-color-private-yellow-450-solid:#d39e50;--g-color-private-yellow-500-solid:#e9ae56;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#ffc56c;--g-color-private-yellow-650-solid:#ffcb7d;--g-color-private-yellow-700-solid:#ffd28d;--g-color-private-yellow-750-solid:#ffd89d;--g-color-private-yellow-800-solid:#ffdfae;--g-color-private-yellow-850-solid:#ffe5be;--g-color-private-yellow-900-solid:#ffecce;--g-color-private-yellow-950-solid:#fff2de;--g-color-private-yellow-1000-solid:#fff5e7;--g-color-private-orange-50-solid:#332420;--g-color-private-orange-100-solid:#3b281f;--g-color-private-orange-150-solid:#432b1e;--g-color-private-orange-200-solid:#54321b;--g-color-private-orange-250-solid:#643919;--g-color-private-orange-300-solid:#754017;--g-color-private-orange-350-solid:#864715;--g-color-private-orange-400-solid:#964e13;--g-color-private-orange-450-solid:#a75510;--g-color-private-orange-500-solid:#b75c0e;--g-color-private-orange-700-solid:#d99255;--g-color-private-orange-800-solid:#e4b186;--g-color-private-red-50:#e5325d1a;--g-color-private-red-100:#e5325d26;--g-color-private-red-150:#e5325d33;--g-color-private-red-200:#e5325d4d;--g-color-private-red-250:#e5325d66;--g-color-private-red-300:#e5325d80;--g-color-private-red-350:#e5325d99;--g-color-private-red-400:#e5325db3;--g-color-private-red-450:#e5325dcc;--g-color-private-red-500:#e5325de6;--g-color-private-red-50-solid:#361f28;--g-color-private-red-100-solid:#3f202b;--g-color-private-red-150-solid:#49212e;--g-color-private-red-200-solid:#5d2334;--g-color-private-red-250-solid:#70253a;--g-color-private-red-300-solid:#842840;--g-color-private-red-350-solid:#972a45;--g-color-private-red-400-solid:#ab2c4b;--g-color-private-red-450-solid:#be2e51;--g-color-private-red-500-solid:#d23057;--g-color-private-red-550-solid:#e5325d;--g-color-private-red-600-solid:#e8476d;--g-color-private-red-650-solid:#ea5b7d;--g-color-private-red-700-solid:#ed708e;--g-color-private-red-750-solid:#ef849e;--g-color-private-red-800-solid:#f299ae;--g-color-private-red-850-solid:#f5adbe;--g-color-private-red-900-solid:#f7c2ce;--g-color-private-red-950-solid:#fad6df;--g-color-private-red-1000-solid:#fbe0e7;--g-color-private-purple-50-solid:#2d2233;--g-color-private-purple-100-solid:#32253c;--g-color-private-purple-150-solid:#382844;--g-color-private-purple-200-solid:#432d55;--g-color-private-purple-250-solid:#4e3266;--g-color-private-purple-300-solid:#593877;--g-color-private-purple-350-solid:#633d88;--g-color-private-purple-400-solid:#6e4299;--g-color-private-purple-450-solid:#7947aa;--g-color-private-purple-500-solid:#844dbb;--g-color-private-cool-grey-50-solid:#28272e;--g-color-private-cool-grey-100-solid:#2b2c34;--g-color-private-cool-grey-150-solid:#2e313a;--g-color-private-cool-grey-200-solid:#353b47;--g-color-private-cool-grey-250-solid:#3b4553;--g-color-private-cool-grey-300-solid:#414f5f;--g-color-private-cool-grey-350-solid:#47586b;--g-color-private-cool-grey-400-solid:#4d6277;--g-color-private-cool-grey-450-solid:#546c84;--g-color-private-cool-grey-500-solid:#5a7690;--g-color-private-cool-grey-750-solid:#a0b3c4;--g-color-private-cool-grey-800-solid:#b0c0ce;--g-color-text-primary:var(--g-color-text-light-primary);--g-color-text-complementary:var(--g-color-text-light-complementary);--g-color-text-secondary:var(--g-color-text-light-secondary);--g-color-text-hint:var(--g-color-text-light-hint);--g-color-text-info:var(--g-color-private-blue-550-solid);--g-color-text-positive:var(--g-color-private-green-550-solid);--g-color-text-warning:var(--g-color-private-yellow-550-solid);--g-color-text-danger:var(--g-color-private-red-550-solid);--g-color-text-utility:var(--g-color-private-purple-600-solid);--g-color-text-misc:var(--g-color-private-cool-grey-600-solid);--g-color-text-info-heavy:var(--g-color-private-blue-600-solid);--g-color-text-positive-heavy:var(--g-color-private-green-600-solid);--g-color-text-warning-heavy:var(--g-color-private-yellow-600-solid);--g-color-text-danger-heavy:var(--g-color-private-red-600-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-650-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-650-solid);--g-color-text-brand:var(--g-color-private-yellow-600-solid);--g-color-text-brand-heavy:var(--g-color-private-yellow-700-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-550-solid);--g-color-text-link-hover:var(--g-color-private-orange-550-solid);--g-color-text-link-visited:var(--g-color-private-purple-600-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-750-solid);--g-color-text-dark-primary:var(--g-color-private-black-900);--g-color-text-dark-complementary:var(--g-color-private-black-700);--g-color-text-dark-secondary:var(--g-color-private-black-500);--g-color-text-dark-hint:var(--g-color-private-black-300);--g-color-text-light-primary:var(--g-color-private-white-850);--g-color-text-light-complementary:var(--g-color-private-white-700);--g-color-text-light-secondary:var(--g-color-private-white-500);--g-color-text-light-hint:var(--g-color-private-white-300);--g-color-text-inverted-primary:var(--g-color-text-dark-primary);--g-color-text-inverted-complementary:var(--g-color-text-dark-complementary);--g-color-text-inverted-secondary:var(--g-color-text-dark-secondary);--g-color-text-inverted-hint:var(--g-color-text-dark-hint);--g-color-base-background:#221d22;--g-color-base-generic:var(--g-color-private-white-100);--g-color-base-generic-hover:var(--g-color-private-white-150);--g-color-base-generic-medium:var(--g-color-private-white-250);--g-color-base-generic-medium-hover:var(--g-color-private-white-300);--g-color-base-generic-accent:var(--g-color-private-white-150);--g-color-base-generic-accent-disabled:var(--g-color-private-white-70);--g-color-base-generic-ultralight:var(--g-color-private-white-20-solid);--g-color-base-simple-hover:var(--g-color-private-white-100);--g-color-base-simple-hover-solid:var(--g-color-private-white-100-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-650-solid);--g-color-base-selection:var(--g-color-private-yellow-150);--g-color-base-selection-hover:var(--g-color-private-yellow-200);--g-color-base-info-light:var(--g-color-private-blue-150);--g-color-base-info-light-hover:var(--g-color-private-blue-200);--g-color-base-info-medium:var(--g-color-private-blue-300);--g-color-base-info-medium-hover:var(--g-color-private-blue-400);--g-color-base-info-heavy:var(--g-color-private-blue-600-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-700-solid);--g-color-base-positive-light:var(--g-color-private-green-150);--g-color-base-positive-light-hover:var(--g-color-private-green-200);--g-color-base-positive-medium:var(--g-color-private-green-300);--g-color-base-positive-medium-hover:var(--g-color-private-green-400);--g-color-base-positive-heavy:var(--g-color-private-green-600-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-700-solid);--g-color-base-warning-light:var(--g-color-private-yellow-150);--g-color-base-warning-light-hover:var(--g-color-private-yellow-200);--g-color-base-warning-medium:var(--g-color-private-yellow-300);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-400);--g-color-base-warning-heavy:var(--g-color-private-yellow-600-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-700-solid);--g-color-base-danger-light:var(--g-color-private-red-150);--g-color-base-danger-light-hover:var(--g-color-private-red-200);--g-color-base-danger-medium:var(--g-color-private-red-300);--g-color-base-danger-medium-hover:var(--g-color-private-red-400);--g-color-base-danger-heavy:var(--g-color-private-red-600-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-700-solid);--g-color-base-utility-light:var(--g-color-private-purple-150);--g-color-base-utility-light-hover:var(--g-color-private-purple-250);--g-color-base-utility-medium:var(--g-color-private-purple-300);--g-color-base-utility-medium-hover:var(--g-color-private-purple-400);--g-color-base-utility-heavy:var(--g-color-private-purple-600-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-700-solid);--g-color-base-neutral-light:var(--g-color-private-white-100);--g-color-base-neutral-light-hover:var(--g-color-private-white-150);--g-color-base-neutral-medium:var(--g-color-private-white-250);--g-color-base-neutral-medium-hover:var(--g-color-private-white-350);--g-color-base-neutral-heavy:var(--g-color-private-white-550);--g-color-base-neutral-heavy-hover:var(--g-color-private-white-650);--g-color-base-misc-light:var(--g-color-private-cool-grey-150);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-200);--g-color-base-misc-medium:var(--g-color-private-cool-grey-300);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-400);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-600-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-700-solid);--g-color-base-light:var(--g-color-private-white-850);--g-color-base-light-hover:var(--g-color-private-white-700);--g-color-base-light-simple-hover:var(--g-color-private-white-150);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-100-solid);--g-color-base-float-hover:var(--g-color-private-white-150-solid);--g-color-base-float-medium:var(--g-color-private-white-150-solid);--g-color-base-float-heavy:var(--g-color-private-white-250-solid);--g-color-base-float-accent:var(--g-color-private-white-150-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-200-solid);--g-color-base-float-announcement:var(--g-color-private-white-150-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-white-150);--g-color-line-generic-hover:var(--g-color-private-white-250);--g-color-line-generic-active:var(--g-color-private-white-300);--g-color-line-generic-accent:var(--g-color-private-white-150);--g-color-line-generic-accent-hover:var(--g-color-private-white-300);--g-color-line-generic-solid:var(--g-color-private-white-150-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-450);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-450);--g-color-line-positive:var(--g-color-private-green-450);--g-color-line-warning:var(--g-color-private-yellow-450);--g-color-line-danger:var(--g-color-private-red-450);--g-color-line-utility:var(--g-color-private-purple-450);--g-color-line-misc:var(--g-color-private-cool-grey-450);--g-color-sfx-veil:var(--g-color-private-black-600);--g-color-sfx-shadow:var(--g-color-private-black-200);--g-color-sfx-shadow-heavy:var(--g-color-private-black-500);--g-color-sfx-shadow-light:var(--g-color-private-black-200);--g-color-sfx-fade:var(--g-color-private-white-250);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-white-150);--g-color-scroll-handle-hover:var(--g-color-private-white-250);--g-color-scroll-corner:var(--g-color-private-white-150);--g-color-infographics-axis:var(--g-color-private-white-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-opaque-150)}.g-root_theme_light-hc{--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#ebf5fe;--g-color-private-blue-100-solid:#e1effd;--g-color-private-blue-150-solid:#d7eafc;--g-color-private-blue-200-solid:#c3e0fb;--g-color-private-blue-250-solid:#afd5f9;--g-color-private-blue-300-solid:#9bcbf8;--g-color-private-blue-350-solid:#86c1f7;--g-color-private-blue-400-solid:#72b6f5;--g-color-private-blue-450-solid:#5eacf4;--g-color-private-blue-500-solid:#4aa1f2;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#328adb;--g-color-private-blue-650-solid:#2f7cc4;--g-color-private-blue-700-solid:#2b6fae;--g-color-private-blue-750-solid:#286198;--g-color-private-blue-800-solid:#245482;--g-color-private-blue-850-solid:#20476b;--g-color-private-blue-900-solid:#1d3955;--g-color-private-blue-950-solid:#192c3f;--g-color-private-blue-1000-solid:#172533;--g-color-private-green-50:#32ba761a;--g-color-private-green-100:#32ba7626;--g-color-private-green-150:#32ba7633;--g-color-private-green-200:#32ba764d;--g-color-private-green-250:#32ba7666;--g-color-private-green-300:#32ba7680;--g-color-private-green-350:#32ba7699;--g-color-private-green-400:#32ba76b3;--g-color-private-green-450:#32ba76cc;--g-color-private-green-500:#32ba76e6;--g-color-private-green-50-solid:#ebf8f1;--g-color-private-green-100-solid:#e0f5ea;--g-color-private-green-150-solid:#d6f1e4;--g-color-private-green-200-solid:#c2ead6;--g-color-private-green-250-solid:#ade3c8;--g-color-private-green-300-solid:#9db;--g-color-private-green-350-solid:#84d6ad;--g-color-private-green-400-solid:#70cf9f;--g-color-private-green-450-solid:#5bc891;--g-color-private-green-500-solid:#47c184;--g-color-private-green-550-solid:#32ba76;--g-color-private-green-600-solid:#2fa96c;--g-color-private-green-650-solid:#2c9862;--g-color-private-green-700-solid:#288758;--g-color-private-green-750-solid:#25764e;--g-color-private-green-800-solid:#264;--g-color-private-green-850-solid:#1f553a;--g-color-private-green-900-solid:#1c4430;--g-color-private-green-950-solid:#183326;--g-color-private-green-1000-solid:#172a21;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#fff9ef;--g-color-private-yellow-100-solid:#fff5e7;--g-color-private-yellow-150-solid:#fff2de;--g-color-private-yellow-200-solid:#ffecce;--g-color-private-yellow-250-solid:#ffe5be;--g-color-private-yellow-300-solid:#ffdfae;--g-color-private-yellow-350-solid:#ffd89d;--g-color-private-yellow-400-solid:#ffd28d;--g-color-private-yellow-450-solid:#ffcb7d;--g-color-private-yellow-500-solid:#ffc56c;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#e7ad55;--g-color-private-yellow-650-solid:#d09b4d;--g-color-private-yellow-700-solid:#b88a46;--g-color-private-yellow-750-solid:#a0793e;--g-color-private-yellow-800-solid:#896837;--g-color-private-yellow-850-solid:#715630;--g-color-private-yellow-900-solid:#594528;--g-color-private-yellow-950-solid:#413421;--g-color-private-yellow-1000-solid:#362b1d;--g-color-private-orange-400-solid:#ffa04d;--g-color-private-orange-500-solid:#ff8519;--g-color-private-orange-600-solid:#e76d02;--g-color-private-orange-650-solid:#d06304;--g-color-private-orange-700-solid:#b85805;--g-color-private-orange-750-solid:#a04e07;--g-color-private-orange-800-solid:#894409;--g-color-private-orange-850-solid:#713a0b;--g-color-private-orange-900-solid:#59300d;--g-color-private-orange-950-solid:#41250e;--g-color-private-orange-1000-solid:#36200f;--g-color-private-red-50:#ff003d1a;--g-color-private-red-100:#ff003d26;--g-color-private-red-150:#ff003d33;--g-color-private-red-200:#ff003d4d;--g-color-private-red-250:#ff003d66;--g-color-private-red-300:#ff003d80;--g-color-private-red-350:#ff003d99;--g-color-private-red-400:#ff003db3;--g-color-private-red-450:#ff003dcc;--g-color-private-red-500:#ff003de6;--g-color-private-red-50-solid:#ffe6ec;--g-color-private-red-100-solid:#ffd9e2;--g-color-private-red-150-solid:#ffccd8;--g-color-private-red-200-solid:#ffb3c5;--g-color-private-red-250-solid:#ff99b1;--g-color-private-red-300-solid:#ff809e;--g-color-private-red-350-solid:#ff668b;--g-color-private-red-400-solid:#ff4d77;--g-color-private-red-450-solid:#ff3364;--g-color-private-red-500-solid:#ff1950;--g-color-private-red-550-solid:#ff003d;--g-color-private-red-600-solid:#e70239;--g-color-private-red-650-solid:#d00334;--g-color-private-red-700-solid:#b80530;--g-color-private-red-750-solid:#a0072c;--g-color-private-red-800-solid:#890928;--g-color-private-red-850-solid:#710a23;--g-color-private-red-900-solid:#590c1f;--g-color-private-red-950-solid:#410e1b;--g-color-private-red-1000-solid:#360e18;--g-color-private-purple-600-solid:#834cb9;--g-color-private-purple-650-solid:#7645a7;--g-color-private-purple-700-solid:#6a3f94;--g-color-private-purple-750-solid:#5d3882;--g-color-private-purple-800-solid:#51326f;--g-color-private-purple-850-solid:#442b5c;--g-color-private-purple-900-solid:#38254a;--g-color-private-purple-950-solid:#2b1e37;--g-color-private-purple-1000-solid:#251b2e;--g-color-private-cool-grey-300-solid:#b5c2cc;--g-color-private-cool-grey-600-solid:#62798c;--g-color-private-cool-grey-650-solid:#596d7e;--g-color-private-cool-grey-700-solid:#506271;--g-color-private-cool-grey-750-solid:#475663;--g-color-private-cool-grey-800-solid:#3f4b56;--g-color-private-cool-grey-850-solid:#363f48;--g-color-private-cool-grey-900-solid:#2d343b;--g-color-private-cool-grey-950-solid:#24282d;--g-color-private-cool-grey-1000-solid:#1f2226;--g-color-text-primary:var(--g-color-text-dark-primary);--g-color-text-complementary:var(--g-color-text-dark-complementary);--g-color-text-secondary:var(--g-color-text-dark-secondary);--g-color-text-hint:var(--g-color-text-dark-hint);--g-color-text-info:var(--g-color-private-blue-650-solid);--g-color-text-positive:var(--g-color-private-green-650-solid);--g-color-text-warning:var(--g-color-private-yellow-700-solid);--g-color-text-danger:var(--g-color-private-red-650-solid);--g-color-text-utility:var(--g-color-private-purple-650-solid);--g-color-text-misc:var(--g-color-private-cool-grey-650-solid);--g-color-text-info-heavy:var(--g-color-private-blue-900-solid);--g-color-text-positive-heavy:var(--g-color-private-green-900-solid);--g-color-text-warning-heavy:var(--g-color-private-orange-900-solid);--g-color-text-danger-heavy:var(--g-color-private-red-900-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-900-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-900-solid);--g-color-text-brand:var(--g-color-private-yellow-700-solid);--g-color-text-brand-heavy:var(--g-color-private-orange-900-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-700-solid);--g-color-text-link-hover:var(--g-color-private-orange-700-solid);--g-color-text-link-visited:var(--g-color-private-purple-600-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-850-solid);--g-color-text-dark-primary:var(--g-color-private-black-1000-solid);--g-color-text-dark-complementary:var(--g-color-private-black-850);--g-color-text-dark-secondary:var(--g-color-private-black-700);--g-color-text-dark-hint:var(--g-color-private-black-500);--g-color-text-light-primary:var(--g-color-private-white-1000-solid);--g-color-text-light-complementary:var(--g-color-private-white-850);--g-color-text-light-secondary:var(--g-color-private-white-700);--g-color-text-light-hint:var(--g-color-private-white-500);--g-color-text-inverted-primary:var(--g-color-text-light-primary);--g-color-text-inverted-complementary:var(--g-color-text-light-complementary);--g-color-text-inverted-secondary:var(--g-color-text-light-secondary);--g-color-text-inverted-hint:var(--g-color-text-light-hint);--g-color-base-background:var(--g-color-private-white-1000-solid);--g-color-base-generic:var(--g-color-private-black-150);--g-color-base-generic-hover:var(--g-color-private-black-300);--g-color-base-generic-medium:var(--g-color-private-black-250);--g-color-base-generic-medium-hover:var(--g-color-private-black-350);--g-color-base-generic-accent:var(--g-color-private-black-250);--g-color-base-generic-accent-disabled:var(--g-color-private-black-150);--g-color-base-generic-ultralight:var(--g-color-private-black-50-solid);--g-color-base-simple-hover:var(--g-color-private-black-150);--g-color-base-simple-hover-solid:var(--g-color-private-black-150-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-650-solid);--g-color-base-selection:var(--g-color-private-yellow-300);--g-color-base-selection-hover:var(--g-color-private-yellow-400);--g-color-base-info-light:var(--g-color-private-blue-250);--g-color-base-info-light-hover:var(--g-color-private-blue-350);--g-color-base-info-medium:var(--g-color-private-blue-400);--g-color-base-info-medium-hover:var(--g-color-private-blue-500);--g-color-base-info-heavy:var(--g-color-private-blue-700-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-850-solid);--g-color-base-positive-light:var(--g-color-private-green-250);--g-color-base-positive-light-hover:var(--g-color-private-green-350);--g-color-base-positive-medium:var(--g-color-private-green-400);--g-color-base-positive-medium-hover:var(--g-color-private-green-500);--g-color-base-positive-heavy:var(--g-color-private-green-700-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-800-solid);--g-color-base-warning-light:var(--g-color-private-yellow-300);--g-color-base-warning-light-hover:var(--g-color-private-yellow-400);--g-color-base-warning-medium:var(--g-color-private-yellow-400);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-550-solid);--g-color-base-warning-heavy:var(--g-color-private-yellow-600-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-700-solid);--g-color-base-danger-light:var(--g-color-private-red-250);--g-color-base-danger-light-hover:var(--g-color-private-red-350);--g-color-base-danger-medium:var(--g-color-private-red-400);--g-color-base-danger-medium-hover:var(--g-color-private-red-500);--g-color-base-danger-heavy:var(--g-color-private-red-700-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-800-solid);--g-color-base-utility-light:var(--g-color-private-purple-250);--g-color-base-utility-light-hover:var(--g-color-private-purple-350);--g-color-base-utility-medium:var(--g-color-private-purple-400);--g-color-base-utility-medium-hover:var(--g-color-private-purple-500);--g-color-base-utility-heavy:var(--g-color-private-purple-700-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-800-solid);--g-color-base-neutral-light:var(--g-color-private-black-150);--g-color-base-neutral-light-hover:var(--g-color-private-black-250);--g-color-base-neutral-medium:var(--g-color-private-black-300);--g-color-base-neutral-medium-hover:var(--g-color-private-black-400);--g-color-base-neutral-heavy:var(--g-color-private-black-550);--g-color-base-neutral-heavy-hover:var(--g-color-private-black-650);--g-color-base-misc-light:var(--g-color-private-cool-grey-250);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-350);--g-color-base-misc-medium:var(--g-color-private-cool-grey-400);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-500);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-700-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-800-solid);--g-color-base-light:var(--g-color-private-white-1000-solid);--g-color-base-light-hover:var(--g-color-private-white-850);--g-color-base-light-simple-hover:var(--g-color-private-white-300);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-1000-solid);--g-color-base-float-hover:var(--g-color-private-black-150-solid);--g-color-base-float-medium:var(--g-color-private-black-550-solid);--g-color-base-float-heavy:var(--g-color-private-black-700-solid);--g-color-base-float-accent:var(--g-color-private-white-1000-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-850);--g-color-base-float-announcement:var(--g-color-private-cool-grey-150-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-black-200);--g-color-line-generic-hover:var(--g-color-private-black-400);--g-color-line-generic-active:var(--g-color-private-black-700);--g-color-line-generic-accent:var(--g-color-private-black-300);--g-color-line-generic-accent-hover:var(--g-color-private-black-700);--g-color-line-generic-solid:var(--g-color-private-black-200-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-450);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-450);--g-color-line-positive:var(--g-color-private-green-450);--g-color-line-warning:var(--g-color-private-yellow-600-solid);--g-color-line-danger:var(--g-color-private-red-450);--g-color-line-utility:var(--g-color-private-purple-450);--g-color-line-misc:var(--g-color-private-cool-grey-450);--g-color-sfx-veil:var(--g-color-private-black-450);--g-color-sfx-shadow:var(--g-color-private-black-300);--g-color-sfx-shadow-heavy:var(--g-color-private-black-600);--g-color-sfx-shadow-light:var(--g-color-private-black-100);--g-color-sfx-fade:var(--g-color-private-white-300);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-black-100);--g-color-scroll-handle-hover:var(--g-color-private-black-150);--g-color-scroll-corner:var(--g-color-private-black-100);--g-color-infographics-axis:var(--g-color-private-black-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-950)}.g-root_theme_dark-hc{--g-color-private-white-50-solid:#1e1d1e;--g-color-private-white-70-solid:#232223;--g-color-private-white-100-solid:#2a292a;--g-color-private-white-150-solid:#363536;--g-color-private-white-200-solid:#414141;--g-color-private-white-250-solid:#4d4d4d;--g-color-private-white-300-solid:#595859;--g-color-private-white-350-solid:#656465;--g-color-private-white-400-solid:#717071;--g-color-private-white-450-solid:#7d7c7d;--g-color-private-white-500-solid:#888;--g-color-private-white-550-solid:#949494;--g-color-private-white-600-solid:#a0a0a0;--g-color-private-white-650-solid:#acacac;--g-color-private-white-700-solid:#b8b8b8;--g-color-private-white-750-solid:#c4c3c4;--g-color-private-white-800-solid:#d0cfd0;--g-color-private-white-850-solid:#d0cfd0;--g-color-private-white-900-solid:#e7e7e7;--g-color-private-white-950-solid:#f3f3f3;--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#161e28;--g-color-private-blue-100-solid:#172533;--g-color-private-blue-150-solid:#192c3f;--g-color-private-blue-200-solid:#1d3955;--g-color-private-blue-250-solid:#20476b;--g-color-private-blue-300-solid:#245482;--g-color-private-blue-350-solid:#286198;--g-color-private-blue-400-solid:#2b6fae;--g-color-private-blue-450-solid:#2f7cc4;--g-color-private-blue-500-solid:#328adb;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#4aa1f2;--g-color-private-blue-650-solid:#5eacf4;--g-color-private-blue-700-solid:#72b6f5;--g-color-private-blue-750-solid:#86c1f7;--g-color-private-blue-800-solid:#9bcbf8;--g-color-private-blue-850-solid:#afd5f9;--g-color-private-blue-900-solid:#c3e0fb;--g-color-private-blue-950-solid:#d7eafc;--g-color-private-blue-1000-solid:#e1effd;--g-color-private-green-50:#4db09b1a;--g-color-private-green-100:#4db09b26;--g-color-private-green-150:#4db09b33;--g-color-private-green-200:#4db09b4d;--g-color-private-green-250:#4db09b66;--g-color-private-green-300:#4db09b80;--g-color-private-green-350:#4db09b99;--g-color-private-green-400:#4db09bb3;--g-color-private-green-450:#4db09bcc;--g-color-private-green-500:#4db09be6;--g-color-private-green-50-solid:#182120;--g-color-private-green-100-solid:#1b2927;--g-color-private-green-150-solid:#1e312d;--g-color-private-green-200-solid:#24413b;--g-color-private-green-250-solid:#2a5149;--g-color-private-green-300-solid:#306157;--g-color-private-green-350-solid:#357064;--g-color-private-green-400-solid:#3b8072;--g-color-private-green-450-solid:#419080;--g-color-private-green-500-solid:#47a08d;--g-color-private-green-550-solid:#4db09b;--g-color-private-green-600-solid:#5fb8a5;--g-color-private-green-650-solid:#71c0af;--g-color-private-green-700-solid:#82c8b9;--g-color-private-green-750-solid:#94d0c3;--g-color-private-green-800-solid:#a6d8cd;--g-color-private-green-850-solid:#b8dfd7;--g-color-private-green-900-solid:#cae7e1;--g-color-private-green-950-solid:#dbefeb;--g-color-private-green-1000-solid:#e4f3f0;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#2a2219;--g-color-private-yellow-100-solid:#362b1d;--g-color-private-yellow-150-solid:#413421;--g-color-private-yellow-200-solid:#594528;--g-color-private-yellow-250-solid:#715630;--g-color-private-yellow-300-solid:#896837;--g-color-private-yellow-350-solid:#a0793e;--g-color-private-yellow-400-solid:#b88a46;--g-color-private-yellow-450-solid:#d09b4d;--g-color-private-yellow-500-solid:#e7ad55;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#ffc56c;--g-color-private-yellow-650-solid:#ffcb7d;--g-color-private-yellow-700-solid:#ffd28d;--g-color-private-yellow-750-solid:#ffd89d;--g-color-private-yellow-800-solid:#ffdfae;--g-color-private-yellow-850-solid:#ffe5be;--g-color-private-yellow-900-solid:#ffecce;--g-color-private-yellow-950-solid:#fff2de;--g-color-private-yellow-1000-solid:#fff5e7;--g-color-private-orange-50-solid:#241911;--g-color-private-orange-100-solid:#2d1d11;--g-color-private-orange-150-solid:#362111;--g-color-private-orange-200-solid:#492a10;--g-color-private-orange-250-solid:#5b3210;--g-color-private-orange-300-solid:#6d3a0f;--g-color-private-orange-350-solid:#7f420e;--g-color-private-orange-400-solid:#914a0e;--g-color-private-orange-450-solid:#a4530d;--g-color-private-orange-500-solid:#b65b0d;--g-color-private-orange-700-solid:#d99255;--g-color-private-orange-800-solid:#e4b186;--g-color-private-red-50:#e5325d1a;--g-color-private-red-100:#e5325d26;--g-color-private-red-150:#e5325d33;--g-color-private-red-200:#e5325d4d;--g-color-private-red-250:#e5325d66;--g-color-private-red-300:#e5325d80;--g-color-private-red-350:#e5325d99;--g-color-private-red-400:#e5325db3;--g-color-private-red-450:#e5325dcc;--g-color-private-red-500:#e5325de6;--g-color-private-red-50-solid:#27141a;--g-color-private-red-100-solid:#32161d;--g-color-private-red-150-solid:#3c1821;--g-color-private-red-200-solid:#511b29;--g-color-private-red-250-solid:#661e30;--g-color-private-red-300-solid:#7c2238;--g-color-private-red-350-solid:#91253f;--g-color-private-red-400-solid:#a62847;--g-color-private-red-450-solid:#bb2b4e;--g-color-private-red-500-solid:#d02f56;--g-color-private-red-550-solid:#e5325d;--g-color-private-red-600-solid:#e8476d;--g-color-private-red-650-solid:#ea5b7d;--g-color-private-red-700-solid:#ed708e;--g-color-private-red-750-solid:#ef849e;--g-color-private-red-800-solid:#f299ae;--g-color-private-red-850-solid:#f5adbe;--g-color-private-red-900-solid:#f7c2ce;--g-color-private-red-950-solid:#fad6df;--g-color-private-red-1000-solid:#fbe0e7;--g-color-private-purple-50-solid:#1f1825;--g-color-private-purple-100-solid:#251b2e;--g-color-private-purple-150-solid:#2b1e37;--g-color-private-purple-200-solid:#38254a;--g-color-private-purple-250-solid:#442b5c;--g-color-private-purple-300-solid:#51326f;--g-color-private-purple-350-solid:#5d3882;--g-color-private-purple-400-solid:#6a3f94;--g-color-private-purple-450-solid:#7645a7;--g-color-private-purple-500-solid:#834cb9;--g-color-private-cool-grey-50-solid:#1a1c20;--g-color-private-cool-grey-100-solid:#1e2227;--g-color-private-cool-grey-150-solid:#22272e;--g-color-private-cool-grey-200-solid:#29323b;--g-color-private-cool-grey-250-solid:#313d49;--g-color-private-cool-grey-300-solid:#394957;--g-color-private-cool-grey-350-solid:#415465;--g-color-private-cool-grey-400-solid:#495f73;--g-color-private-cool-grey-450-solid:#506a80;--g-color-private-cool-grey-500-solid:#58758e;--g-color-private-cool-grey-750-solid:#a0b3c4;--g-color-private-cool-grey-800-solid:#b0c0ce;--g-color-text-primary:var(--g-color-text-light-primary);--g-color-text-complementary:var(--g-color-text-light-complementary);--g-color-text-secondary:var(--g-color-text-light-secondary);--g-color-text-hint:var(--g-color-text-light-hint);--g-color-text-info:var(--g-color-private-blue-650-solid);--g-color-text-positive:var(--g-color-private-green-650-solid);--g-color-text-warning:var(--g-color-private-yellow-650-solid);--g-color-text-danger:var(--g-color-private-red-650-solid);--g-color-text-utility:var(--g-color-private-purple-650-solid);--g-color-text-misc:var(--g-color-private-cool-grey-650-solid);--g-color-text-info-heavy:var(--g-color-private-blue-850-solid);--g-color-text-positive-heavy:var(--g-color-private-green-850-solid);--g-color-text-warning-heavy:var(--g-color-private-yellow-850-solid);--g-color-text-danger-heavy:var(--g-color-private-red-850-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-850-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-850-solid);--g-color-text-brand:var(--g-color-private-yellow-600-solid);--g-color-text-brand-heavy:var(--g-color-private-yellow-700-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-550-solid);--g-color-text-link-hover:var(--g-color-private-orange-550-solid);--g-color-text-link-visited:var(--g-color-private-purple-650-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-800-solid);--g-color-text-dark-primary:var(--g-color-private-black-1000-solid);--g-color-text-dark-complementary:var(--g-color-private-black-800);--g-color-text-dark-secondary:var(--g-color-private-black-600);--g-color-text-dark-hint:var(--g-color-private-black-400);--g-color-text-light-primary:var(--g-color-private-white-1000-solid);--g-color-text-light-complementary:var(--g-color-private-white-800);--g-color-text-light-secondary:var(--g-color-private-white-600);--g-color-text-light-hint:var(--g-color-private-white-400);--g-color-text-inverted-primary:var(--g-color-text-dark-primary);--g-color-text-inverted-complementary:var(--g-color-text-dark-complementary);--g-color-text-inverted-secondary:var(--g-color-text-dark-secondary);--g-color-text-inverted-hint:var(--g-color-text-dark-hint);--g-color-base-background:#121112;--g-color-base-generic:var(--g-color-private-white-100);--g-color-base-generic-hover:var(--g-color-private-white-250);--g-color-base-generic-medium:var(--g-color-private-white-250);--g-color-base-generic-medium-hover:var(--g-color-private-white-400);--g-color-base-generic-accent:var(--g-color-private-white-200);--g-color-base-generic-accent-disabled:var(--g-color-private-white-150);--g-color-base-generic-ultralight:var(--g-color-private-white-50);--g-color-base-simple-hover:var(--g-color-private-white-250);--g-color-base-simple-hover-solid:var(--g-color-private-white-250-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-700-solid);--g-color-base-selection:var(--g-color-private-yellow-250);--g-color-base-selection-hover:var(--g-color-private-yellow-400);--g-color-base-info-light:var(--g-color-private-blue-250);--g-color-base-info-light-hover:var(--g-color-private-blue-400);--g-color-base-info-medium:var(--g-color-private-blue-450);--g-color-base-info-medium-hover:var(--g-color-private-blue-600-solid);--g-color-base-info-heavy:var(--g-color-private-blue-700-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-850-solid);--g-color-base-positive-light:var(--g-color-private-green-250);--g-color-base-positive-light-hover:var(--g-color-private-green-400);--g-color-base-positive-medium:var(--g-color-private-green-450);--g-color-base-positive-medium-hover:var(--g-color-private-green-600-solid);--g-color-base-positive-heavy:var(--g-color-private-green-700-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-850-solid);--g-color-base-warning-light:var(--g-color-private-yellow-250);--g-color-base-warning-light-hover:var(--g-color-private-yellow-400);--g-color-base-warning-medium:var(--g-color-private-yellow-450);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-600-solid);--g-color-base-warning-heavy:var(--g-color-private-yellow-700-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-850-solid);--g-color-base-danger-light:var(--g-color-private-red-250);--g-color-base-danger-light-hover:var(--g-color-private-red-400);--g-color-base-danger-medium:var(--g-color-private-red-450);--g-color-base-danger-medium-hover:var(--g-color-private-red-600-solid);--g-color-base-danger-heavy:var(--g-color-private-red-700-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-850-solid);--g-color-base-utility-light:var(--g-color-private-purple-250);--g-color-base-utility-light-hover:var(--g-color-private-purple-400);--g-color-base-utility-medium:var(--g-color-private-purple-450);--g-color-base-utility-medium-hover:var(--g-color-private-purple-600-solid);--g-color-base-utility-heavy:var(--g-color-private-purple-700-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-850-solid);--g-color-base-neutral-light:var(--g-color-private-white-200);--g-color-base-neutral-light-hover:var(--g-color-private-white-350);--g-color-base-neutral-medium:var(--g-color-private-white-400);--g-color-base-neutral-medium-hover:var(--g-color-private-white-550);--g-color-base-neutral-heavy:var(--g-color-private-white-650);--g-color-base-neutral-heavy-hover:var(--g-color-private-white-750);--g-color-base-misc-light:var(--g-color-private-cool-grey-250);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-400);--g-color-base-misc-medium:var(--g-color-private-cool-grey-450);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-600-solid);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-700-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-850-solid);--g-color-base-light:var(--g-color-private-white-850);--g-color-base-light-hover:var(--g-color-private-white-700);--g-color-base-light-simple-hover:var(--g-color-private-white-150);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-100-solid);--g-color-base-float-hover:var(--g-color-private-white-200-solid);--g-color-base-float-medium:var(--g-color-private-white-200-solid);--g-color-base-float-heavy:var(--g-color-private-white-300-solid);--g-color-base-float-accent:var(--g-color-private-white-300-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-400-solid);--g-color-base-float-announcement:var(--g-color-private-white-200-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-white-150);--g-color-line-generic-hover:var(--g-color-private-white-250);--g-color-line-generic-active:var(--g-color-private-white-600);--g-color-line-generic-accent:var(--g-color-private-white-350);--g-color-line-generic-accent-hover:var(--g-color-private-white-800);--g-color-line-generic-solid:var(--g-color-private-white-150-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-550-solid);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-550-solid);--g-color-line-positive:var(--g-color-private-green-550-solid);--g-color-line-warning:var(--g-color-private-yellow-550-solid);--g-color-line-danger:var(--g-color-private-red-550-solid);--g-color-line-utility:var(--g-color-private-purple-550-solid);--g-color-line-misc:var(--g-color-private-cool-grey-550-solid);--g-color-sfx-veil:var(--g-color-private-black-700);--g-color-sfx-shadow:var(--g-color-private-black-200);--g-color-sfx-shadow-heavy:var(--g-color-private-black-400);--g-color-sfx-shadow-light:var(--g-color-private-black-200);--g-color-sfx-fade:var(--g-color-private-white-250);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-white-150);--g-color-scroll-handle-hover:var(--g-color-private-white-250);--g-color-scroll-corner:var(--g-color-private-white-150);--g-color-infographics-axis:var(--g-color-private-white-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-opaque-150)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar){scrollbar-color:var(--g-color-scroll-handle) var(--g-color-scroll-track);scrollbar-width:var(--g-scrollbar-width)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar{background:var(--g-color-scroll-track);height:var(--g-scrollbar-width);width:var(--g-scrollbar-width)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-track,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-track{background:var(--g-color-scroll-track)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-corner,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-corner{background:var(--g-color-scroll-corner)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-thumb,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-thumb{background:var(--g-color-scroll-handle)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-thumb:hover,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-thumb:hover{background:var(--g-color-scroll-handle-hover)}@keyframes g-loading-animation{0%{background-position:-12px 0}to{background-position:0 0}}:root:has(body.g-root_theme_light),:root:has(body.g-root_theme_light-hc){color-scheme:light}:root:has(body.g-root_theme_dark),:root:has(body.g-root_theme_dark-hc){color-scheme:dark}@media(prefers-reduced-motion:reduce){*,:after,:before{animation-duration:.001ms!important;animation-iteration-count:1!important;scroll-behavior:auto!important;transition-duration:.001ms!important}}.g-root{--g-text-header-font-weight:500;--g-text-subheader-font-weight:600;--g-text-display-font-weight:500;--g-text-accent-font-weight:500}.g-root_theme_light{--g-color-base-background:#fff;--g-color-base-brand:var(--g-color-private-blue-550-solid);--g-color-base-brand-hover:var(--g-color-private-blue-600-solid);--g-color-base-selection:var(--g-color-private-blue-100);--g-color-base-selection-hover:var(--g-color-private-blue-200);--g-color-line-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand:var(--g-color-private-blue-600-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-700-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-600-solid);--g-color-text-link-hover:var(--g-color-private-blue-800-solid);--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-1000-solid:#fff;--g-color-private-black-50:#0000000d;--g-color-private-black-70:#00000012;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-20-solid:#fafafa;--g-color-private-black-50-solid:#f2f2f2;--g-color-private-black-100-solid:#e5e5e5;--g-color-private-black-150-solid:#d9d9d9;--g-color-private-black-200-solid:#ccc;--g-color-private-black-250-solid:#bfbfbf;--g-color-private-black-300-solid:#b3b3b3;--g-color-private-black-350-solid:#a6a6a6;--g-color-private-black-400-solid:#999;--g-color-private-black-450-solid:#8c8c8c;--g-color-private-black-500-solid:grey;--g-color-private-black-550-solid:#737373;--g-color-private-black-600-solid:#666;--g-color-private-black-650-solid:#595959;--g-color-private-black-700-solid:#4c4c4c;--g-color-private-black-750-solid:#404040;--g-color-private-black-800-solid:#333;--g-color-private-black-850-solid:#262626;--g-color-private-black-900-solid:#1a1a1a;--g-color-private-black-950-solid:#0d0d0d;--g-color-private-black-1000-solid:#000;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#eef3ff;--g-color-private-blue-100-solid:#e5ecff;--g-color-private-blue-150-solid:#dce6ff;--g-color-private-blue-200-solid:#cbdaff;--g-color-private-blue-250-solid:#bacdff;--g-color-private-blue-300-solid:#a8c1ff;--g-color-private-blue-350-solid:#97b4ff;--g-color-private-blue-400-solid:#86a8ff;--g-color-private-blue-450-solid:#749bff;--g-color-private-blue-500-solid:#638fff;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#4e79eb;--g-color-private-blue-650-solid:#4a71d6;--g-color-private-blue-700-solid:#4768c2;--g-color-private-blue-750-solid:#4360ad;--g-color-private-blue-800-solid:#3f5799;--g-color-private-blue-850-solid:#3c4f85;--g-color-private-blue-900-solid:#384670;--g-color-private-blue-950-solid:#343d5c;--g-color-private-blue-1000-solid:#333952;--g-color-private-green-50:#3bc9351a;--g-color-private-green-100:#3bc93526;--g-color-private-green-150:#3bc93533;--g-color-private-green-200:#3bc9354d;--g-color-private-green-250:#3bc93566;--g-color-private-green-300:#3bc93580;--g-color-private-green-350:#3bc93599;--g-color-private-green-400:#3bc935b3;--g-color-private-green-450:#3bc935cc;--g-color-private-green-500:#3bc935e6;--g-color-private-green-50-solid:#ebfaeb;--g-color-private-green-100-solid:#e2f7e1;--g-color-private-green-150-solid:#d8f4d7;--g-color-private-green-200-solid:#c4efc2;--g-color-private-green-250-solid:#b1e9ae;--g-color-private-green-300-solid:#9de49a;--g-color-private-green-350-solid:#89df86;--g-color-private-green-400-solid:#76d972;--g-color-private-green-450-solid:#62d45d;--g-color-private-green-500-solid:#4fce49;--g-color-private-green-550-solid:#3bc935;--g-color-private-green-600-solid:#3ab935;--g-color-private-green-650-solid:#38aa35;--g-color-private-green-700-solid:#379a34;--g-color-private-green-750-solid:#358a34;--g-color-private-green-800-solid:#347b34;--g-color-private-green-850-solid:#336b34;--g-color-private-green-900-solid:#315b34;--g-color-private-green-950-solid:#304b33;--g-color-private-green-1000-solid:#2f4433;--g-color-private-yellow-50:#ffdb4d1a;--g-color-private-yellow-100:#ffdb4d26;--g-color-private-yellow-150:#ffdb4d33;--g-color-private-yellow-200:#ffdb4d4d;--g-color-private-yellow-250:#ffdb4d66;--g-color-private-yellow-300:#ffdb4d80;--g-color-private-yellow-350:#ffdb4d99;--g-color-private-yellow-400:#ffdb4db3;--g-color-private-yellow-450:#ffdb4dcc;--g-color-private-yellow-500:#ffdb4de6;--g-color-private-yellow-50-solid:#fffbed;--g-color-private-yellow-100-solid:#fffae4;--g-color-private-yellow-150-solid:#fff8db;--g-color-private-yellow-200-solid:#fff4ca;--g-color-private-yellow-250-solid:#fff1b8;--g-color-private-yellow-300-solid:#ffeda6;--g-color-private-yellow-350-solid:#ffe994;--g-color-private-yellow-400-solid:#ffe682;--g-color-private-yellow-450-solid:#ffe271;--g-color-private-yellow-500-solid:#ffdf5f;--g-color-private-yellow-550-solid:#ffdb4d;--g-color-private-yellow-600-solid:#eac94a;--g-color-private-yellow-650-solid:#d5b848;--g-color-private-yellow-700-solid:#c0a645;--g-color-private-yellow-750-solid:#ab9543;--g-color-private-yellow-800-solid:#968340;--g-color-private-yellow-850-solid:#81723d;--g-color-private-yellow-900-solid:#6c603b;--g-color-private-yellow-950-solid:#574f38;--g-color-private-yellow-1000-solid:#4d4637;--g-color-private-orange-50:#ff77001a;--g-color-private-orange-100:#ff770026;--g-color-private-orange-150:#f703;--g-color-private-orange-200:#ff77004d;--g-color-private-orange-250:#f706;--g-color-private-orange-300:#ff770080;--g-color-private-orange-350:#f709;--g-color-private-orange-400:#ff7700b3;--g-color-private-orange-450:#f70c;--g-color-private-orange-500:#ff7700e6;--g-color-private-orange-50-solid:#fff1e6;--g-color-private-orange-100-solid:#ffebd9;--g-color-private-orange-150-solid:#ffe4cc;--g-color-private-orange-200-solid:#ffd6b3;--g-color-private-orange-250-solid:#ffc999;--g-color-private-orange-300-solid:#ffbb80;--g-color-private-orange-350-solid:#ffad66;--g-color-private-orange-400-solid:#ffa04c;--g-color-private-orange-450-solid:#ff9233;--g-color-private-orange-500-solid:#ff851a;--g-color-private-orange-550-solid:#f70;--g-color-private-orange-600-solid:#ea7005;--g-color-private-orange-650-solid:#d5680a;--g-color-private-orange-700-solid:#c0600f;--g-color-private-orange-750-solid:#ab5914;--g-color-private-orange-800-solid:#965119;--g-color-private-orange-850-solid:#814a1f;--g-color-private-orange-900-solid:#6c4324;--g-color-private-orange-950-solid:#573b29;--g-color-private-orange-1000-solid:#4d372b;--g-color-private-red-50:#ff04001a;--g-color-private-red-100:#ff040026;--g-color-private-red-150:#ff040033;--g-color-private-red-200:#ff04004d;--g-color-private-red-250:#ff040066;--g-color-private-red-300:#ff040080;--g-color-private-red-350:#ff040099;--g-color-private-red-400:#ff0400b3;--g-color-private-red-450:#ff0400cc;--g-color-private-red-500:#ff0400e6;--g-color-private-red-50-solid:#ffe6e6;--g-color-private-red-100-solid:#ffd9d9;--g-color-private-red-150-solid:#ffcdcc;--g-color-private-red-200-solid:#ffb4b3;--g-color-private-red-250-solid:#ff9b99;--g-color-private-red-300-solid:#ff8280;--g-color-private-red-350-solid:#ff6966;--g-color-private-red-400-solid:#ff504c;--g-color-private-red-450-solid:#ff3733;--g-color-private-red-500-solid:#ff1e1a;--g-color-private-red-550-solid:#ff0400;--g-color-private-red-600-solid:#ea0805;--g-color-private-red-650-solid:#d50c0a;--g-color-private-red-700-solid:#c0100f;--g-color-private-red-750-solid:#ab1414;--g-color-private-red-800-solid:#961819;--g-color-private-red-850-solid:#811c1f;--g-color-private-red-900-solid:#6c2024;--g-color-private-red-950-solid:#572429;--g-color-private-red-1000-solid:#4d262b;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#f4eefa;--g-color-private-purple-100-solid:#eee5f7;--g-color-private-purple-150-solid:#e9dcf5;--g-color-private-purple-200-solid:#ddcbf0;--g-color-private-purple-250-solid:#d2baeb;--g-color-private-purple-300-solid:#c7a9e6;--g-color-private-purple-350-solid:#bc97e0;--g-color-private-purple-400-solid:#b186db;--g-color-private-purple-450-solid:#a575d6;--g-color-private-purple-500-solid:#9a63d1;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#854ebd;--g-color-private-purple-650-solid:#7b4aad;--g-color-private-purple-700-solid:#72479e;--g-color-private-purple-750-solid:#68438f;--g-color-private-purple-800-solid:#5e3f80;--g-color-private-purple-850-solid:#543b70;--g-color-private-purple-900-solid:#4a3761;--g-color-private-purple-950-solid:#413452;--g-color-private-purple-1000-solid:#3c324a;--g-color-private-cool-grey-50:#6b84991a;--g-color-private-cool-grey-100:#6b849926;--g-color-private-cool-grey-150:#6b849933;--g-color-private-cool-grey-200:#6b84994d;--g-color-private-cool-grey-250:#6b849966;--g-color-private-cool-grey-300:#6b849980;--g-color-private-cool-grey-350:#6b849999;--g-color-private-cool-grey-400:#6b8499b3;--g-color-private-cool-grey-450:#6b8499cc;--g-color-private-cool-grey-500:#6b8499e6;--g-color-private-cool-grey-50-solid:#f0f3f5;--g-color-private-cool-grey-100-solid:#e9edf0;--g-color-private-cool-grey-150-solid:#e1e6eb;--g-color-private-cool-grey-200-solid:#d3dae0;--g-color-private-cool-grey-250-solid:#c4ced6;--g-color-private-cool-grey-300-solid:#b5c1cc;--g-color-private-cool-grey-350-solid:#a6b5c2;--g-color-private-cool-grey-400-solid:#97a9b8;--g-color-private-cool-grey-450-solid:#899dad;--g-color-private-cool-grey-500-solid:#7a90a3;--g-color-private-cool-grey-550-solid:#6b8499;--g-color-private-cool-grey-600-solid:#657b8f;--g-color-private-cool-grey-650-solid:#5f7285;--g-color-private-cool-grey-700-solid:#586a7a;--g-color-private-cool-grey-750-solid:#526170;--g-color-private-cool-grey-800-solid:#4c5866;--g-color-private-cool-grey-850-solid:#464f5c;--g-color-private-cool-grey-900-solid:#404652;--g-color-private-cool-grey-950-solid:#393e47;--g-color-private-cool-grey-1000-solid:#363942}.g-root_theme_light-hc{--g-color-base-background:#fff;--g-color-base-brand:var(--g-color-private-blue-600-solid);--g-color-base-brand-hover:var(--g-color-private-blue-800-solid);--g-color-base-selection:var(--g-color-private-blue-250);--g-color-base-selection-hover:var(--g-color-private-blue-350);--g-color-line-brand:var(--g-color-private-blue-600-solid);--g-color-text-brand:var(--g-color-private-blue-650-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-900-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-650-solid);--g-color-text-link-hover:var(--g-color-private-blue-850-solid);--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-1000-solid:#fff;--g-color-private-black-50:#0000000d;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-50-solid:#f2f2f2;--g-color-private-black-100-solid:#e5e5e5;--g-color-private-black-150-solid:#d9d9d9;--g-color-private-black-200-solid:#ccc;--g-color-private-black-250-solid:#bfbfbf;--g-color-private-black-300-solid:#b3b3b3;--g-color-private-black-350-solid:#a6a6a6;--g-color-private-black-400-solid:#999;--g-color-private-black-450-solid:#8c8c8c;--g-color-private-black-500-solid:grey;--g-color-private-black-550-solid:#737373;--g-color-private-black-600-solid:#666;--g-color-private-black-650-solid:#595959;--g-color-private-black-700-solid:#4c4c4c;--g-color-private-black-750-solid:#404040;--g-color-private-black-800-solid:#333;--g-color-private-black-850-solid:#262626;--g-color-private-black-900-solid:#1a1a1a;--g-color-private-black-950-solid:#0d0d0d;--g-color-private-black-1000-solid:#000;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#eef3ff;--g-color-private-blue-100-solid:#e5ecff;--g-color-private-blue-150-solid:#dce6ff;--g-color-private-blue-200-solid:#cbdaff;--g-color-private-blue-250-solid:#bacdff;--g-color-private-blue-300-solid:#a8c1ff;--g-color-private-blue-350-solid:#97b4ff;--g-color-private-blue-400-solid:#86a8ff;--g-color-private-blue-450-solid:#749bff;--g-color-private-blue-500-solid:#638fff;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#4d79e9;--g-color-private-blue-650-solid:#486fd4;--g-color-private-blue-700-solid:#4366be;--g-color-private-blue-750-solid:#3f5ca8;--g-color-private-blue-800-solid:#3a5393;--g-color-private-blue-850-solid:#35497d;--g-color-private-blue-900-solid:#304067;--g-color-private-blue-950-solid:#2c3651;--g-color-private-blue-1000-solid:#293147;--g-color-private-green-50:#3bc9351a;--g-color-private-green-100:#3bc93526;--g-color-private-green-150:#3bc93533;--g-color-private-green-200:#3bc9354d;--g-color-private-green-250:#3bc93566;--g-color-private-green-300:#3bc93580;--g-color-private-green-350:#3bc93599;--g-color-private-green-400:#3bc935b3;--g-color-private-green-450:#3bc935cc;--g-color-private-green-500:#3bc935e6;--g-color-private-green-50-solid:#ebfaeb;--g-color-private-green-100-solid:#e2f7e1;--g-color-private-green-150-solid:#d8f4d7;--g-color-private-green-200-solid:#c4efc2;--g-color-private-green-250-solid:#b1e9ae;--g-color-private-green-300-solid:#9de49a;--g-color-private-green-350-solid:#89df86;--g-color-private-green-400-solid:#76d972;--g-color-private-green-450-solid:#62d45d;--g-color-private-green-500-solid:#4fce49;--g-color-private-green-550-solid:#3bc935;--g-color-private-green-600-solid:#38b833;--g-color-private-green-650-solid:#36a832;--g-color-private-green-700-solid:#339730;--g-color-private-green-750-solid:#31872f;--g-color-private-green-800-solid:#2f762e;--g-color-private-green-850-solid:#2c652c;--g-color-private-green-900-solid:#29552b;--g-color-private-green-950-solid:#274429;--g-color-private-green-1000-solid:#263c28;--g-color-private-yellow-50:#ffdb4d1a;--g-color-private-yellow-100:#ffdb4d26;--g-color-private-yellow-150:#ffdb4d33;--g-color-private-yellow-200:#ffdb4d4d;--g-color-private-yellow-250:#ffdb4d66;--g-color-private-yellow-300:#ffdb4d80;--g-color-private-yellow-350:#ffdb4d99;--g-color-private-yellow-400:#ffdb4db3;--g-color-private-yellow-450:#ffdb4dcc;--g-color-private-yellow-500:#ffdb4de6;--g-color-private-yellow-50-solid:#fffbed;--g-color-private-yellow-100-solid:#fffae4;--g-color-private-yellow-150-solid:#fff8db;--g-color-private-yellow-200-solid:#fff4ca;--g-color-private-yellow-250-solid:#fff1b8;--g-color-private-yellow-300-solid:#ffeda6;--g-color-private-yellow-350-solid:#ffe994;--g-color-private-yellow-400-solid:#ffe682;--g-color-private-yellow-450-solid:#ffe271;--g-color-private-yellow-500-solid:#ffdf5f;--g-color-private-yellow-550-solid:#ffdb4d;--g-color-private-yellow-600-solid:#e9c949;--g-color-private-yellow-650-solid:#d3b645;--g-color-private-yellow-700-solid:#bda441;--g-color-private-yellow-750-solid:#a7913d;--g-color-private-yellow-800-solid:#907f3a;--g-color-private-yellow-850-solid:#7a6d36;--g-color-private-yellow-900-solid:#645a32;--g-color-private-yellow-950-solid:#4e482e;--g-color-private-yellow-1000-solid:#433f2c;--g-color-private-orange-50:#ff77001a;--g-color-private-orange-100:#ff770026;--g-color-private-orange-150:#f703;--g-color-private-orange-200:#ff77004d;--g-color-private-orange-250:#f706;--g-color-private-orange-300:#ff770080;--g-color-private-orange-350:#f709;--g-color-private-orange-400:#ff7700b3;--g-color-private-orange-450:#f70c;--g-color-private-orange-500:#ff7700e6;--g-color-private-orange-50-solid:#fff1e6;--g-color-private-orange-100-solid:#ffebd9;--g-color-private-orange-150-solid:#ffe4cc;--g-color-private-orange-200-solid:#ffd6b3;--g-color-private-orange-250-solid:#ffc999;--g-color-private-orange-300-solid:#ffbb80;--g-color-private-orange-350-solid:#ffad66;--g-color-private-orange-400-solid:#ffa04c;--g-color-private-orange-450-solid:#ff9233;--g-color-private-orange-500-solid:#ff851a;--g-color-private-orange-550-solid:#f70;--g-color-private-orange-600-solid:#e96f04;--g-color-private-orange-650-solid:#d36608;--g-color-private-orange-700-solid:#bd5e0b;--g-color-private-orange-750-solid:#a7550f;--g-color-private-orange-800-solid:#904d13;--g-color-private-orange-850-solid:#7a4517;--g-color-private-orange-900-solid:#643c1b;--g-color-private-orange-950-solid:#4e341e;--g-color-private-orange-1000-solid:#433020;--g-color-private-red-50:#ff04001a;--g-color-private-red-100:#ff040026;--g-color-private-red-150:#ff040033;--g-color-private-red-200:#ff04004d;--g-color-private-red-250:#ff040066;--g-color-private-red-300:#ff040080;--g-color-private-red-350:#ff040099;--g-color-private-red-400:#ff0400b3;--g-color-private-red-450:#ff0400cc;--g-color-private-red-500:#ff0400e6;--g-color-private-red-50-solid:#ffe6e6;--g-color-private-red-100-solid:#ffd9d9;--g-color-private-red-150-solid:#ffcdcc;--g-color-private-red-200-solid:#ffb4b3;--g-color-private-red-250-solid:#ff9b99;--g-color-private-red-300-solid:#ff8280;--g-color-private-red-350-solid:#ff6966;--g-color-private-red-400-solid:#ff504c;--g-color-private-red-450-solid:#ff3733;--g-color-private-red-500-solid:#ff1e1a;--g-color-private-red-550-solid:#ff0400;--g-color-private-red-600-solid:#e90804;--g-color-private-red-650-solid:#d30b08;--g-color-private-red-700-solid:#bd0e0b;--g-color-private-red-750-solid:#a6110f;--g-color-private-red-800-solid:#901413;--g-color-private-red-850-solid:#7a1717;--g-color-private-red-900-solid:#641a1b;--g-color-private-red-950-solid:#4e1d1e;--g-color-private-red-1000-solid:#431e20;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#f4eefa;--g-color-private-purple-100-solid:#eee5f7;--g-color-private-purple-150-solid:#e9dcf5;--g-color-private-purple-200-solid:#ddcbf0;--g-color-private-purple-250-solid:#d2baeb;--g-color-private-purple-300-solid:#c7a9e6;--g-color-private-purple-350-solid:#bc97e0;--g-color-private-purple-400-solid:#b186db;--g-color-private-purple-450-solid:#a575d6;--g-color-private-purple-500-solid:#9a63d1;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#844dbb;--g-color-private-purple-650-solid:#7949ab;--g-color-private-purple-700-solid:#6e449a;--g-color-private-purple-750-solid:#633f8a;--g-color-private-purple-800-solid:#593b79;--g-color-private-purple-850-solid:#4e3668;--g-color-private-purple-900-solid:#433158;--g-color-private-purple-950-solid:#382c47;--g-color-private-purple-1000-solid:#322a3f;--g-color-private-cool-grey-50:#6b84991a;--g-color-private-cool-grey-100:#6b849926;--g-color-private-cool-grey-150:#6b849933;--g-color-private-cool-grey-200:#6b84994d;--g-color-private-cool-grey-250:#6b849966;--g-color-private-cool-grey-300:#6b849980;--g-color-private-cool-grey-350:#6b849999;--g-color-private-cool-grey-400:#6b8499b3;--g-color-private-cool-grey-450:#6b8499cc;--g-color-private-cool-grey-500:#6b8499e6;--g-color-private-cool-grey-50-solid:#f0f3f5;--g-color-private-cool-grey-100-solid:#e9edf0;--g-color-private-cool-grey-150-solid:#e1e6eb;--g-color-private-cool-grey-200-solid:#d3dae0;--g-color-private-cool-grey-250-solid:#c4ced6;--g-color-private-cool-grey-300-solid:#b5c1cc;--g-color-private-cool-grey-350-solid:#a6b5c2;--g-color-private-cool-grey-400-solid:#97a9b8;--g-color-private-cool-grey-450-solid:#899dad;--g-color-private-cool-grey-500-solid:#7a90a3;--g-color-private-cool-grey-550-solid:#6b8499;--g-color-private-cool-grey-600-solid:#647a8e;--g-color-private-cool-grey-650-solid:#5c7182;--g-color-private-cool-grey-700-solid:#556776;--g-color-private-cool-grey-750-solid:#4e5d6b;--g-color-private-cool-grey-800-solid:#465360;--g-color-private-cool-grey-850-solid:#3f4a54;--g-color-private-cool-grey-900-solid:#384049;--g-color-private-cool-grey-950-solid:#31363d;--g-color-private-cool-grey-1000-solid:#2d3237}.g-root_theme_dark{--g-color-base-background:#2d2c33;--g-color-base-brand:var(--g-color-private-blue-450-solid);--g-color-base-brand-hover:var(--g-color-private-blue-600-solid);--g-color-base-selection:var(--g-color-private-blue-150);--g-color-base-selection-hover:var(--g-color-private-blue-200);--g-color-line-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-600-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-550-solid);--g-color-text-link-hover:var(--g-color-private-blue-700-solid);--g-color-private-white-20:#ffffff05;--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-20-solid:#313037;--g-color-private-white-50-solid:#38373d;--g-color-private-white-70-solid:#3c3b41;--g-color-private-white-100-solid:#424147;--g-color-private-white-150-solid:#4d4c52;--g-color-private-white-200-solid:#57565c;--g-color-private-white-250-solid:#616166;--g-color-private-white-300-solid:#6c6b70;--g-color-private-white-350-solid:#77767a;--g-color-private-white-400-solid:#818085;--g-color-private-white-450-solid:#8b8b8f;--g-color-private-white-500-solid:#969699;--g-color-private-white-550-solid:#a0a0a3;--g-color-private-white-600-solid:#ababad;--g-color-private-white-650-solid:#b6b5b8;--g-color-private-white-700-solid:#c0c0c2;--g-color-private-white-750-solid:#cacacc;--g-color-private-white-800-solid:#d5d5d6;--g-color-private-white-850-solid:#dfdfe0;--g-color-private-white-900-solid:#eaeaeb;--g-color-private-white-950-solid:#f5f5f5;--g-color-private-white-1000-solid:#fff;--g-color-private-white-opaque-150:#4c4b51f2;--g-color-private-black-20:#00000005;--g-color-private-black-50:#0000000d;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-1000-solid:#000;--g-color-private-black-rock-850:#2d2c33;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#313547;--g-color-private-blue-100-solid:#333952;--g-color-private-blue-150-solid:#343d5c;--g-color-private-blue-200-solid:#384670;--g-color-private-blue-250-solid:#3c4e85;--g-color-private-blue-300-solid:#405799;--g-color-private-blue-350-solid:#4360ad;--g-color-private-blue-400-solid:#4768c2;--g-color-private-blue-450-solid:#4b71d6;--g-color-private-blue-500-solid:#4e79eb;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#638fff;--g-color-private-blue-650-solid:#759bff;--g-color-private-blue-700-solid:#86a8ff;--g-color-private-blue-750-solid:#97b4ff;--g-color-private-blue-800-solid:#a9c1ff;--g-color-private-blue-850-solid:#bacdff;--g-color-private-blue-900-solid:#cbdaff;--g-color-private-blue-950-solid:#dce6ff;--g-color-private-blue-1000-solid:#e5ecff;--g-color-private-green-50:#5bb5571a;--g-color-private-green-100:#5bb55726;--g-color-private-green-150:#5bb55733;--g-color-private-green-200:#5bb5574d;--g-color-private-green-250:#5bb55766;--g-color-private-green-300:#5bb55780;--g-color-private-green-350:#5bb55799;--g-color-private-green-400:#5bb557b3;--g-color-private-green-450:#5bb557cc;--g-color-private-green-500:#5bb557e6;--g-color-private-green-50-solid:#323a37;--g-color-private-green-100-solid:#344138;--g-color-private-green-150-solid:#36473a;--g-color-private-green-200-solid:#3b553e;--g-color-private-green-250-solid:#3f6341;--g-color-private-green-300-solid:#447145;--g-color-private-green-350-solid:#497e49;--g-color-private-green-400-solid:#4d8c4c;--g-color-private-green-450-solid:#529a50;--g-color-private-green-500-solid:#56a753;--g-color-private-green-550-solid:#5bb557;--g-color-private-green-600-solid:#6bbc68;--g-color-private-green-650-solid:#7cc479;--g-color-private-green-700-solid:#8ccb89;--g-color-private-green-750-solid:#9dd39a;--g-color-private-green-800-solid:#addaab;--g-color-private-green-850-solid:#bde1bc;--g-color-private-green-900-solid:#cee9cd;--g-color-private-green-950-solid:#def0dd;--g-color-private-green-1000-solid:#e6f4e6;--g-color-private-yellow-50:#ffcb001a;--g-color-private-yellow-100:#ffcb0026;--g-color-private-yellow-150:#ffcb0033;--g-color-private-yellow-200:#ffcb004d;--g-color-private-yellow-250:#ffcb0066;--g-color-private-yellow-300:#ffcb0080;--g-color-private-yellow-350:#ffcb0099;--g-color-private-yellow-400:#ffcb00b3;--g-color-private-yellow-450:#ffcb00cc;--g-color-private-yellow-500:#ffcb00e6;--g-color-private-yellow-50-solid:#423c2e;--g-color-private-yellow-100-solid:#4d442b;--g-color-private-yellow-150-solid:#574c29;--g-color-private-yellow-200-solid:#6c5c24;--g-color-private-yellow-250-solid:#816c1f;--g-color-private-yellow-300-solid:#967c19;--g-color-private-yellow-350-solid:#ab8c14;--g-color-private-yellow-400-solid:#c09b0f;--g-color-private-yellow-450-solid:#d5ab0a;--g-color-private-yellow-500-solid:#e9ba04;--g-color-private-yellow-550-solid:#ffcb00;--g-color-private-yellow-600-solid:#ffd01a;--g-color-private-yellow-650-solid:#ffd533;--g-color-private-yellow-700-solid:#ffdb4c;--g-color-private-yellow-750-solid:#ffe066;--g-color-private-yellow-800-solid:#ffe580;--g-color-private-yellow-850-solid:#ffea99;--g-color-private-yellow-900-solid:#ffefb3;--g-color-private-yellow-950-solid:#fff5cc;--g-color-private-yellow-1000-solid:#fff7d9;--g-color-private-orange-50:#c8630c1a;--g-color-private-orange-100:#c8630c26;--g-color-private-orange-150:#c8630c33;--g-color-private-orange-200:#c8630c4d;--g-color-private-orange-250:#c8630c66;--g-color-private-orange-300:#c8630c80;--g-color-private-orange-350:#c8630c99;--g-color-private-orange-400:#c8630cb3;--g-color-private-orange-450:#c8630ccc;--g-color-private-orange-500:#c8630ce6;--g-color-private-orange-50-solid:#3d322f;--g-color-private-orange-100-solid:#44342d;--g-color-private-orange-150-solid:#4c372b;--g-color-private-orange-200-solid:#5c3d27;--g-color-private-orange-250-solid:#6b4223;--g-color-private-orange-300-solid:#7b4720;--g-color-private-orange-350-solid:#8a4d1c;--g-color-private-orange-400-solid:#995218;--g-color-private-orange-450-solid:#a95814;--g-color-private-orange-500-solid:#b95e10;--g-color-private-orange-550-solid:#c8630c;--g-color-private-orange-600-solid:#ce7324;--g-color-private-orange-650-solid:#d3823d;--g-color-private-orange-700-solid:#d89255;--g-color-private-orange-750-solid:#dea16d;--g-color-private-orange-800-solid:#e3b185;--g-color-private-orange-850-solid:#e9c19e;--g-color-private-orange-900-solid:#efd0b6;--g-color-private-orange-950-solid:#f4e0ce;--g-color-private-orange-1000-solid:#f7e8db;--g-color-private-red-50:#e849451a;--g-color-private-red-100:#e8494526;--g-color-private-red-150:#e8494533;--g-color-private-red-200:#e849454d;--g-color-private-red-250:#e8494566;--g-color-private-red-300:#e8494580;--g-color-private-red-350:#e8494599;--g-color-private-red-400:#e84945b3;--g-color-private-red-450:#e84945cc;--g-color-private-red-500:#e84945e6;--g-color-private-red-50-solid:#402f35;--g-color-private-red-100-solid:#493036;--g-color-private-red-150-solid:#523237;--g-color-private-red-200-solid:#653539;--g-color-private-red-250-solid:#78383a;--g-color-private-red-300-solid:#8a3a3c;--g-color-private-red-350-solid:#9d3d3e;--g-color-private-red-400-solid:#b04040;--g-color-private-red-450-solid:#c34341;--g-color-private-red-500-solid:#d54644;--g-color-private-red-550-solid:#e84945;--g-color-private-red-600-solid:#ea5b58;--g-color-private-red-650-solid:#ec6d6b;--g-color-private-red-700-solid:#ef7f7d;--g-color-private-red-750-solid:#f19290;--g-color-private-red-800-solid:#f3a4a2;--g-color-private-red-850-solid:#f6b6b5;--g-color-private-red-900-solid:#f8c8c7;--g-color-private-red-950-solid:#fadbda;--g-color-private-red-1000-solid:#fce4e3;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#373042;--g-color-private-purple-100-solid:#3c324a;--g-color-private-purple-150-solid:#413452;--g-color-private-purple-200-solid:#4a3761;--g-color-private-purple-250-solid:#543b70;--g-color-private-purple-300-solid:#5e3f80;--g-color-private-purple-350-solid:#68438f;--g-color-private-purple-400-solid:#72479e;--g-color-private-purple-450-solid:#7b4aad;--g-color-private-purple-500-solid:#854ebd;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#9a63d1;--g-color-private-purple-650-solid:#a575d6;--g-color-private-purple-700-solid:#b186db;--g-color-private-purple-750-solid:#bc97e0;--g-color-private-purple-800-solid:#c7a9e6;--g-color-private-purple-850-solid:#d2baeb;--g-color-private-purple-900-solid:#ddcbf0;--g-color-private-purple-950-solid:#e9dcf5;--g-color-private-purple-1000-solid:#eee5f7;--g-color-private-cool-grey-50:#60809c1a;--g-color-private-cool-grey-100:#60809c26;--g-color-private-cool-grey-150:#60809c33;--g-color-private-cool-grey-200:#60809c4d;--g-color-private-cool-grey-250:#60809c66;--g-color-private-cool-grey-300:#60809c80;--g-color-private-cool-grey-350:#60809c99;--g-color-private-cool-grey-400:#60809cb3;--g-color-private-cool-grey-450:#60809ccc;--g-color-private-cool-grey-500:#60809ce6;--g-color-private-cool-grey-50-solid:#32343e;--g-color-private-cool-grey-100-solid:#353943;--g-color-private-cool-grey-150-solid:#373d48;--g-color-private-cool-grey-200-solid:#3c4552;--g-color-private-cool-grey-250-solid:#414e5d;--g-color-private-cool-grey-300-solid:#465667;--g-color-private-cool-grey-350-solid:#4c5e72;--g-color-private-cool-grey-400-solid:#51677d;--g-color-private-cool-grey-450-solid:#566f87;--g-color-private-cool-grey-500-solid:#5b7892;--g-color-private-cool-grey-550-solid:#60809c;--g-color-private-cool-grey-600-solid:#708da6;--g-color-private-cool-grey-650-solid:#8099b0;--g-color-private-cool-grey-700-solid:#90a6ba;--g-color-private-cool-grey-750-solid:#a0b3c3;--g-color-private-cool-grey-800-solid:#b0bfcd;--g-color-private-cool-grey-850-solid:#bfccd7;--g-color-private-cool-grey-900-solid:#cfd9e1;--g-color-private-cool-grey-950-solid:#dfe6eb;--g-color-private-cool-grey-1000-solid:#e7ecf0}.g-root_theme_dark-hc{--g-color-base-background:#222326;--g-color-base-brand:var(--g-color-private-blue-450-solid);--g-color-base-brand-hover:var(--g-color-private-blue-650-solid);--g-color-base-selection:var(--g-color-private-blue-250);--g-color-base-selection-hover:var(--g-color-private-blue-400);--g-color-line-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand:var(--g-color-private-blue-650-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-850-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-650-solid);--g-color-text-link-hover:var(--g-color-private-blue-800-solid);--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-50-solid:#2d2e31;--g-color-private-white-100-solid:#38393c;--g-color-private-white-150-solid:#434447;--g-color-private-white-200-solid:#4e4f51;--g-color-private-white-250-solid:#595a5c;--g-color-private-white-300-solid:#646567;--g-color-private-white-350-solid:#6f7072;--g-color-private-white-400-solid:#7a7b7d;--g-color-private-white-450-solid:#858688;--g-color-private-white-500-solid:#909193;--g-color-private-white-550-solid:#9c9c9d;--g-color-private-white-600-solid:#a7a7a8;--g-color-private-white-650-solid:#b2b2b3;--g-color-private-white-700-solid:#bdbdbe;--g-color-private-white-750-solid:#c8c8c9;--g-color-private-white-800-solid:#d3d3d4;--g-color-private-white-850-solid:#dededf;--g-color-private-white-900-solid:#e9e9e9;--g-color-private-white-950-solid:#f4f4f4;--g-color-private-white-1000-solid:#fff;--g-color-private-white-opaque-150:#38393cf7;--g-color-private-black-20:#00000005;--g-color-private-black-50:#0000000d;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-1000-solid:#000;--g-color-private-black-rock-850:#2d2c33;--g-color-private-black-rock-950:#222326;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#272d3c;--g-color-private-blue-100-solid:#293147;--g-color-private-blue-150-solid:#2c3651;--g-color-private-blue-200-solid:#304067;--g-color-private-blue-250-solid:#35497d;--g-color-private-blue-300-solid:#3a5393;--g-color-private-blue-350-solid:#3f5ca8;--g-color-private-blue-400-solid:#4466be;--g-color-private-blue-450-solid:#486fd4;--g-color-private-blue-500-solid:#4d79e9;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#638fff;--g-color-private-blue-650-solid:#759bff;--g-color-private-blue-700-solid:#86a8ff;--g-color-private-blue-750-solid:#97b4ff;--g-color-private-blue-800-solid:#a9c1ff;--g-color-private-blue-850-solid:#bacdff;--g-color-private-blue-900-solid:#cbdaff;--g-color-private-blue-950-solid:#dce6ff;--g-color-private-blue-1000-solid:#e5ecff;--g-color-private-green-50:#5bb5571a;--g-color-private-green-100:#5bb55726;--g-color-private-green-150:#000;--g-color-private-green-200:#5bb5574d;--g-color-private-green-250:#5bb55766;--g-color-private-green-300:#5bb55780;--g-color-private-green-350:#5bb55799;--g-color-private-green-400:#5bb557b3;--g-color-private-green-450:#5bb557cc;--g-color-private-green-500:#5bb557e6;--g-color-private-green-50-solid:#28322b;--g-color-private-green-100-solid:#2b392d;--g-color-private-green-150-solid:#2d4030;--g-color-private-green-200-solid:#334f35;--g-color-private-green-250-solid:#395d3a;--g-color-private-green-300-solid:#3f6c3f;--g-color-private-green-350-solid:#447b43;--g-color-private-green-400-solid:#4a8948;--g-color-private-green-450-solid:#50984d;--g-color-private-green-500-solid:#55a652;--g-color-private-green-550-solid:#5bb557;--g-color-private-green-600-solid:#6bbc68;--g-color-private-green-650-solid:#7cc479;--g-color-private-green-700-solid:#8ccb89;--g-color-private-green-750-solid:#9dd39a;--g-color-private-green-800-solid:#addaab;--g-color-private-green-850-solid:#bde1bc;--g-color-private-green-900-solid:#cee9cd;--g-color-private-green-950-solid:#def0dd;--g-color-private-green-1000-solid:#e6f4e6;--g-color-private-yellow-50:#ffcb001a;--g-color-private-yellow-100:#ffcb0026;--g-color-private-yellow-150:#ffcb0033;--g-color-private-yellow-200:#ffcb004d;--g-color-private-yellow-250:#ffcb0066;--g-color-private-yellow-300:#ffcb0080;--g-color-private-yellow-350:#ffcb0099;--g-color-private-yellow-400:#ffcb00b3;--g-color-private-yellow-450:#ffcb00cc;--g-color-private-yellow-500:#ffcb00e6;--g-color-private-yellow-50-solid:#383422;--g-color-private-yellow-100-solid:#433c20;--g-color-private-yellow-150-solid:#4e451e;--g-color-private-yellow-200-solid:#64551b;--g-color-private-yellow-250-solid:#7a6617;--g-color-private-yellow-300-solid:#907713;--g-color-private-yellow-350-solid:#a7880f;--g-color-private-yellow-400-solid:#bd990b;--g-color-private-yellow-450-solid:#d3a908;--g-color-private-yellow-500-solid:#e9ba04;--g-color-private-yellow-550-solid:#ffcb00;--g-color-private-yellow-600-solid:#ffd01a;--g-color-private-yellow-650-solid:#ffd533;--g-color-private-yellow-700-solid:#ffdb4c;--g-color-private-yellow-750-solid:#ffe066;--g-color-private-yellow-800-solid:#ffe580;--g-color-private-yellow-850-solid:#ffea99;--g-color-private-yellow-900-solid:#ffefb3;--g-color-private-yellow-950-solid:#fff5cc;--g-color-private-yellow-1000-solid:#fff7d9;--g-color-private-orange-50:#c8630c1a;--g-color-private-orange-100:#c8630c26;--g-color-private-orange-150:#c8630c33;--g-color-private-orange-200:#c8630c4d;--g-color-private-orange-250:#c8630c66;--g-color-private-orange-300:#c8630c80;--g-color-private-orange-350:#c8630c99;--g-color-private-orange-400:#c8630cb3;--g-color-private-orange-450:#c8630ccc;--g-color-private-orange-500:#c8630ce6;--g-color-private-orange-50-solid:#332923;--g-color-private-orange-100-solid:#3b2d22;--g-color-private-orange-150-solid:#433021;--g-color-private-orange-200-solid:#54361e;--g-color-private-orange-250-solid:#643d1c;--g-color-private-orange-300-solid:#754319;--g-color-private-orange-350-solid:#864916;--g-color-private-orange-400-solid:#965014;--g-color-private-orange-450-solid:#a75611;--g-color-private-orange-500-solid:#b75d0f;--g-color-private-orange-550-solid:#c8630c;--g-color-private-orange-600-solid:#ce7324;--g-color-private-orange-650-solid:#d3823d;--g-color-private-orange-700-solid:#d89255;--g-color-private-orange-750-solid:#dea16d;--g-color-private-orange-800-solid:#e3b185;--g-color-private-orange-850-solid:#e9c19e;--g-color-private-orange-900-solid:#efd0b6;--g-color-private-orange-950-solid:#f4e0ce;--g-color-private-orange-1000-solid:#f7e8db;--g-color-private-red-50:#e849451a;--g-color-private-red-100:#e8494526;--g-color-private-red-150:#e8494533;--g-color-private-red-200:#e849454d;--g-color-private-red-250:#e8494566;--g-color-private-red-300:#e8494580;--g-color-private-red-350:#e8494599;--g-color-private-red-400:#e84945b3;--g-color-private-red-450:#e84945cc;--g-color-private-red-500:#e84945e6;--g-color-private-red-50-solid:#362729;--g-color-private-red-100-solid:#40292b;--g-color-private-red-150-solid:#4a2b2c;--g-color-private-red-200-solid:#5d2e2f;--g-color-private-red-250-solid:#713233;--g-color-private-red-300-solid:#853636;--g-color-private-red-350-solid:#993a39;--g-color-private-red-400-solid:#ac3d3c;--g-color-private-red-450-solid:#c0413f;--g-color-private-red-500-solid:#d44542;--g-color-private-red-550-solid:#e84945;--g-color-private-red-600-solid:#ea5b58;--g-color-private-red-650-solid:#ec6d6b;--g-color-private-red-700-solid:#ef7f7d;--g-color-private-red-750-solid:#f19290;--g-color-private-red-800-solid:#f3a4a2;--g-color-private-red-850-solid:#f6b6b5;--g-color-private-red-900-solid:#f8c8c7;--g-color-private-red-950-solid:#fadbda;--g-color-private-red-1000-solid:#fce4e3;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#2d2837;--g-color-private-purple-100-solid:#322a3f;--g-color-private-purple-150-solid:#382c47;--g-color-private-purple-200-solid:#433158;--g-color-private-purple-250-solid:#4e3668;--g-color-private-purple-300-solid:#593b79;--g-color-private-purple-350-solid:#633f8a;--g-color-private-purple-400-solid:#6e449a;--g-color-private-purple-450-solid:#7949ab;--g-color-private-purple-500-solid:#844dbb;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#9a63d1;--g-color-private-purple-650-solid:#a575d6;--g-color-private-purple-700-solid:#b186db;--g-color-private-purple-750-solid:#bc97e0;--g-color-private-purple-800-solid:#c7a9e6;--g-color-private-purple-850-solid:#d2baeb;--g-color-private-purple-900-solid:#ddcbf0;--g-color-private-purple-950-solid:#e9dcf5;--g-color-private-purple-1000-solid:#eee5f7;--g-color-private-cool-grey-50:#60809c1a;--g-color-private-cool-grey-100:#60809c26;--g-color-private-cool-grey-150:#60809c33;--g-color-private-cool-grey-200:#60809c4d;--g-color-private-cool-grey-250:#60809c66;--g-color-private-cool-grey-300:#60809c80;--g-color-private-cool-grey-350:#60809c99;--g-color-private-cool-grey-400:#60809cb3;--g-color-private-cool-grey-450:#60809ccc;--g-color-private-cool-grey-500:#60809ce6;--g-color-private-cool-grey-50-solid:#282c32;--g-color-private-cool-grey-100-solid:#2b3138;--g-color-private-cool-grey-150-solid:#2e363e;--g-color-private-cool-grey-200-solid:#353f49;--g-color-private-cool-grey-250-solid:#3b4855;--g-color-private-cool-grey-300-solid:#415161;--g-color-private-cool-grey-350-solid:#475b6d;--g-color-private-cool-grey-400-solid:#4d6479;--g-color-private-cool-grey-450-solid:#546d84;--g-color-private-cool-grey-500-solid:#5a7790;--g-color-private-cool-grey-550-solid:#60809c;--g-color-private-cool-grey-600-solid:#708da6;--g-color-private-cool-grey-650-solid:#8099b0;--g-color-private-cool-grey-700-solid:#90a6ba;--g-color-private-cool-grey-750-solid:#a0b3c3;--g-color-private-cool-grey-800-solid:#b0bfcd;--g-color-private-cool-grey-850-solid:#bfccd7;--g-color-private-cool-grey-900-solid:#cfd9e1;--g-color-private-cool-grey-950-solid:#dfe6eb;--g-color-private-cool-grey-1000-solid:#e7ecf0}.unipika{--color-unipika-default:#a9a9a9;--color-unipika-string:#594c4c;--color-unipika-key:#d36b6b;--color-unipika-null:#594c4c;--color-unipika-int:#0095ff;--color-unipika-uint:#c200ff;--color-unipika-float:#ff00b9;--color-unipika-bool:#00ba0a;--color-unipika-date:#693;--color-unipika-interval:#399;--color-unipika-escape-text:#c7254e;--color-unipika-escape-back:#ffeff3;--color-unipika-binary-back:#fcf8e3;--color-unipika-binary-after:#888;--color-unipika-uuid:#c63;--color-unipika-tag-url:#04b;--color-unipika-tag-url-hover:#c00;color:var(--color-unipika-default);overflow-wrap:break-word;white-space:pre-wrap;word-break:normal}.unipika .pg_category_e,.unipika .pg_category_i,.unipika .pg_category_s,.unipika .string,.unipika .yql_string,.unipika .yql_utf8{color:var(--color-unipika-string)}.unipika .key,.unipika .special-key{color:var(--color-unipika-key)}.unipika .special-key{font-style:italic}.unipika .null,.unipika .yql_null{color:var(--color-unipika-null)}.unipika .null{font-style:italic}.unipika .yql_null{text-transform:uppercase}.unipika .int64,.unipika .number,.unipika .pg_category_n,.unipika .yql_int16,.unipika .yql_int32,.unipika .yql_int64,.unipika .yql_int8{color:var(--color-unipika-int)}.unipika .pg_category_a,.unipika .uint64,.unipika .yql_uint16,.unipika .yql_uint32,.unipika .yql_uint64,.unipika .yql_uint8{color:var(--color-unipika-uint)}.unipika .double,.unipika .pg_category_c,.unipika .yql_decimal,.unipika .yql_double,.unipika .yql_float{color:var(--color-unipika-float)}.unipika .boolean,.unipika .pg_category_b,.unipika .yql_bool,.unipika .yql_enum{color:var(--color-unipika-bool)}.unipika .pg_category_d,.unipika .yql_date,.unipika .yql_date32,.unipika .yql_datetime,.unipika .yql_datetime64,.unipika .yql_timestamp,.unipika .yql_timestamp64,.unipika .yql_tzdate,.unipika .yql_tzdate32,.unipika .yql_tzdatetime,.unipika .yql_tzdatetime64,.unipika .yql_tztimestamp,.unipika .yql_tztimestamp64{color:var(--color-unipika-date)}.unipika .pg_category_t,.unipika .yql_interval,.unipika .yql_interval64{color:var(--color-unipika-interval)}.unipika .yql_tagged.tag_image{vertical-align:top}.unipika .escape{background-color:var(--color-unipika-escape-back);color:var(--color-unipika-escape-text)}.unipika .quote{color:var(--color-unipika-default)}.unipika .binary,.unipika .incomplete,.unipika .pg_category_v{background-color:var(--color-unipika-binary-back)}.unipika .binary:after,.unipika .incomplete:after{color:var(--color-unipika-binary-after);padding-inline-start:.8em}.unipika .incomplete:after{content:"[truncated]";white-space:nowrap}.unipika .binary:after{content:"[binary]";white-space:nowrap}.unipika .incomplete.binary:after{content:"[truncated][binary]";white-space:nowrap}.unipika .pg_category_g,.unipika .yql_uuid{color:var(--color-unipika-uuid)}.unipika .pg_category_g.binary,.unipika .pg_category_g.incomplete,.unipika .yql_uuid.binary,.unipika .yql_uuid.incomplete{background:none}.unipika .pg_category_g.binary:after,.unipika .pg_category_g.incomplete:after,.unipika .yql_uuid.binary:after,.unipika .yql_uuid.incomplete:after{content:"";display:none}.unipika .tag_url{color:var(--color-unipika-tag-url);text-decoration:none}.unipika .tag_url:hover{color:var(--color-unipika-tag-url-hover)}.unipika-wrapper_inline_yes .unipika{display:inline-block}.g-root .unipika{font-family:var(--g-font-family-monospace)}.g-root .unipika-wrapper .g-root .unipika{border:0;margin:0;padding:0}.g-root_theme_dark .unipika,.g-root_theme_dark-hc .unipika{--color-unipika-default:#707070;--color-unipika-string:#9a8e8e;--color-unipika-key:#d36b6b;--color-unipika-null:#9a8e8e;--color-unipika-int:#0095ff;--color-unipika-uint:#c200ff;--color-unipika-float:#ff00b9;--color-unipika-bool:#00ba0a;--color-unipika-date:#693;--color-unipika-interval:#399;--color-unipika-escape-text:#c7254e;--color-unipika-escape-back:#292e1f;--color-unipika-binary-back:#292e1f;--color-unipika-binary-after:#666;--color-unipika-uuid:#c63;--color-unipika-tag-url:#47b;--color-unipika-tag-url-hover:#6af}.g-root_theme_light,.g-root_theme_light-hc{--gil-color-object-base:var(--g-color-private-yellow-550-solid);--gil-color-object-accent-heavy:var(--g-color-private-orange-650-solid);--gil-color-object-hightlight:var(--g-color-private-yellow-350-solid);--gil-color-shadow-over-object:var(--g-color-private-yellow-650-solid);--gil-color-background-lines:var(--g-color-private-black-450-solid);--gil-color-background-shapes:var(--g-color-private-black-50-solid);--gil-color-object-accent-light:var(--g-color-private-white-1000-solid);--gil-color-object-danger:var(--g-color-private-red-550-solid)}.g-root_theme_dark,.g-root_theme_dark-hc{--gil-color-object-base:var(--g-color-private-yellow-550-solid);--gil-color-object-accent-heavy:var(--g-color-private-orange-650-solid);--gil-color-object-hightlight:var(--g-color-private-yellow-700-solid);--gil-color-shadow-over-object:var(--g-color-private-yellow-500-solid);--gil-color-background-lines:var(--g-color-private-white-550-solid);--gil-color-background-shapes:var(--g-color-private-white-200-solid);--gil-color-object-accent-light:var(--g-color-private-white-1000-solid);--gil-color-object-danger:var(--g-color-private-red-550-solid)}.g-root_theme_dark,.g-root_theme_dark-hc,.g-root_theme_light,.g-root_theme_light-hc{--gil-color-object-base:var(--g-color-private-blue-450-solid);--gil-color-object-accent-heavy:var(--g-color-private-blue-850-solid);--gil-color-object-hightlight:var(--g-color-private-blue-350-solid);--gil-color-shadow-over-object:var(--g-color-private-blue-650-solid)}body{-webkit-font-smoothing:antialiased;-moz-osx-font-smoothing:grayscale;font-family:-apple-system,BlinkMacSystemFont,Segoe UI,Roboto,Oxygen,Ubuntu,Cantarell,Fira Sans,Droid Sans,Helvetica Neue,sans-serif;margin:0}code{font-family:source-code-pro,Menlo,Monaco,Consolas,Courier New,monospace} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/css/main.c06e6faa.css b/ydb/core/viewer/monitoring/static/css/main.c06e6faa.css deleted file mode 100644 index ab6b2b516d09..000000000000 --- a/ydb/core/viewer/monitoring/static/css/main.c06e6faa.css +++ /dev/null @@ -1,9 +0,0 @@ -@charset "UTF-8";@import url(https://fonts.googleapis.com/css2?family=Rubik&display=swap);.g-root{--g-font-family-sans:"Inter","Helvetica Neue","Helvetica","Arial",sans-serif;--g-font-family-monospace:"Menlo","Monaco","Consolas","Ubuntu Mono","Liberation Mono","DejaVu Sans Mono","Courier New","Courier",monospace;--g-text-body-font-family:var(--g-font-family-sans);--g-text-caption-font-family:var(--g-font-family-sans);--g-text-header-font-family:var(--g-font-family-sans);--g-text-subheader-font-family:var(--g-font-family-sans);--g-text-display-font-family:var(--g-font-family-sans);--g-text-code-font-family:var(--g-font-family-monospace);--g-text-body-font-weight:400;--g-text-caption-font-weight:400;--g-text-header-font-weight:600;--g-text-display-font-weight:600;--g-text-code-font-weight:400;--g-text-accent-font-weight:600;--g-text-body-1-font-size:13px;--g-text-body-1-line-height:18px;--g-text-body-2-font-size:15px;--g-text-body-2-line-height:20px;--g-text-body-3-font-size:17px;--g-text-body-3-line-height:24px;--g-text-body-short-font-size:13px;--g-text-body-short-line-height:16px;--g-text-caption-1-font-size:9px;--g-text-caption-1-line-height:12px;--g-text-caption-2-font-size:11px;--g-text-caption-2-line-height:16px;--g-text-header-1-font-size:20px;--g-text-header-1-line-height:24px;--g-text-header-2-font-size:24px;--g-text-header-2-line-height:28px;--g-text-subheader-1-font-size:13px;--g-text-subheader-1-line-height:18px;--g-text-subheader-2-font-size:15px;--g-text-subheader-2-line-height:20px;--g-text-subheader-3-font-size:17px;--g-text-subheader-3-line-height:24px;--g-text-display-1-font-size:28px;--g-text-display-1-line-height:36px;--g-text-display-2-font-size:32px;--g-text-display-2-line-height:40px;--g-text-display-3-font-size:40px;--g-text-display-3-line-height:48px;--g-text-display-4-font-size:48px;--g-text-display-4-line-height:52px;--g-text-code-1-font-size:12px;--g-text-code-1-line-height:18px;--g-text-code-2-font-size:14px;--g-text-code-2-line-height:20px;--g-text-code-3-font-size:16px;--g-text-code-3-line-height:24px;--g-text-code-inline-1-font-size:12px;--g-text-code-inline-1-line-height:14px;--g-text-code-inline-2-font-size:14px;--g-text-code-inline-2-line-height:16px;--g-text-code-inline-3-font-size:16px;--g-text-code-inline-3-line-height:20px;--g-spacing-base:4px;--g-spacing-0:calc(var(--g-spacing-base)*0);--g-spacing-half:calc(var(--g-spacing-base)*0.5);--g-spacing-1:var(--g-spacing-base);--g-spacing-2:calc(var(--g-spacing-base)*2);--g-spacing-3:calc(var(--g-spacing-base)*3);--g-spacing-4:calc(var(--g-spacing-base)*4);--g-spacing-5:calc(var(--g-spacing-base)*5);--g-spacing-6:calc(var(--g-spacing-base)*6);--g-spacing-7:calc(var(--g-spacing-base)*7);--g-spacing-8:calc(var(--g-spacing-base)*8);--g-spacing-9:calc(var(--g-spacing-base)*9);--g-spacing-10:calc(var(--g-spacing-base)*10);--g-scrollbar-width:12px;--g-border-radius-xs:3px;--g-border-radius-s:5px;--g-border-radius-m:6px;--g-border-radius-l:8px;--g-border-radius-xl:10px;--g-focus-border-radius:2px;background:var(--g-color-base-background);color:var(--g-color-text-primary);font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-root[dir=ltr],body.g-root{--g-flow-direction:1;--g-flow-is-ltr:1;--g-flow-is-rtl:0}.g-root[dir=rtl]{--g-flow-direction:-1;--g-flow-is-ltr:0;--g-flow-is-rtl:1}.g-root_theme_light{--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#ebf5fe;--g-color-private-blue-100-solid:#e1effd;--g-color-private-blue-150-solid:#d7eafc;--g-color-private-blue-200-solid:#c3e0fb;--g-color-private-blue-250-solid:#afd5f9;--g-color-private-blue-300-solid:#9bcbf8;--g-color-private-blue-350-solid:#86c1f7;--g-color-private-blue-400-solid:#72b6f5;--g-color-private-blue-450-solid:#5eacf4;--g-color-private-blue-500-solid:#4aa1f2;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#348bdc;--g-color-private-blue-650-solid:#327fc8;--g-color-private-blue-700-solid:#3072b3;--g-color-private-blue-750-solid:#2e669e;--g-color-private-blue-800-solid:#2c5a8a;--g-color-private-blue-850-solid:#2a4e75;--g-color-private-blue-900-solid:#284260;--g-color-private-blue-950-solid:#26354b;--g-color-private-blue-1000-solid:#252f41;--g-color-private-green-50:#32ba761a;--g-color-private-green-100:#32ba7626;--g-color-private-green-150:#32ba7633;--g-color-private-green-200:#32ba764d;--g-color-private-green-250:#32ba7666;--g-color-private-green-300:#32ba7680;--g-color-private-green-350:#32ba7699;--g-color-private-green-400:#32ba76b3;--g-color-private-green-450:#32ba76cc;--g-color-private-green-500:#32ba76e6;--g-color-private-green-50-solid:#ebf8f1;--g-color-private-green-100-solid:#e0f5ea;--g-color-private-green-150-solid:#d6f1e4;--g-color-private-green-200-solid:#c2ead6;--g-color-private-green-250-solid:#ade3c8;--g-color-private-green-300-solid:#9db;--g-color-private-green-350-solid:#84d6ad;--g-color-private-green-400-solid:#70cf9f;--g-color-private-green-450-solid:#5bc891;--g-color-private-green-500-solid:#47c184;--g-color-private-green-550-solid:#32ba76;--g-color-private-green-600-solid:#30aa6e;--g-color-private-green-650-solid:#2f9b65;--g-color-private-green-700-solid:#2d8b5d;--g-color-private-green-750-solid:#2c7b54;--g-color-private-green-800-solid:#2a6c4c;--g-color-private-green-850-solid:#285c44;--g-color-private-green-900-solid:#274c3b;--g-color-private-green-950-solid:#253c33;--g-color-private-green-1000-solid:#24352f;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#fff9ef;--g-color-private-yellow-100-solid:#fff5e7;--g-color-private-yellow-150-solid:#fff2de;--g-color-private-yellow-200-solid:#ffecce;--g-color-private-yellow-250-solid:#ffe5be;--g-color-private-yellow-300-solid:#ffdfae;--g-color-private-yellow-350-solid:#ffd89d;--g-color-private-yellow-400-solid:#ffd28d;--g-color-private-yellow-450-solid:#ffcb7d;--g-color-private-yellow-500-solid:#ffc56c;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#e9ae56;--g-color-private-yellow-650-solid:#d39e50;--g-color-private-yellow-700-solid:#bd8e4b;--g-color-private-yellow-750-solid:#a77e45;--g-color-private-yellow-800-solid:#916e3f;--g-color-private-yellow-850-solid:#7a5d39;--g-color-private-yellow-900-solid:#644d33;--g-color-private-yellow-950-solid:#4e3d2e;--g-color-private-yellow-1000-solid:#43352b;--g-color-private-orange-400-solid:#ffa04d;--g-color-private-orange-500-solid:#ff8519;--g-color-private-orange-600-solid:#e96e03;--g-color-private-orange-650-solid:#d36507;--g-color-private-orange-700-solid:#bd5c0a;--g-color-private-orange-750-solid:#a7530e;--g-color-private-orange-800-solid:#914a11;--g-color-private-orange-850-solid:#7a4114;--g-color-private-orange-900-solid:#643818;--g-color-private-orange-950-solid:#4e2f1b;--g-color-private-orange-1000-solid:#432b1d;--g-color-private-red-50:#ff003d1a;--g-color-private-red-100:#ff003d26;--g-color-private-red-150:#ff003d33;--g-color-private-red-200:#ff003d4d;--g-color-private-red-250:#ff003d66;--g-color-private-red-300:#ff003d80;--g-color-private-red-350:#ff003d99;--g-color-private-red-400:#ff003db3;--g-color-private-red-450:#ff003dcc;--g-color-private-red-500:#ff003de6;--g-color-private-red-50-solid:#ffe6ec;--g-color-private-red-100-solid:#ffd9e2;--g-color-private-red-150-solid:#ffccd8;--g-color-private-red-200-solid:#ffb3c5;--g-color-private-red-250-solid:#ff99b1;--g-color-private-red-300-solid:#ff809e;--g-color-private-red-350-solid:#ff668b;--g-color-private-red-400-solid:#ff4d77;--g-color-private-red-450-solid:#ff3364;--g-color-private-red-500-solid:#ff1950;--g-color-private-red-550-solid:#ff003d;--g-color-private-red-600-solid:#e9033a;--g-color-private-red-650-solid:#d30638;--g-color-private-red-700-solid:#bd0935;--g-color-private-red-750-solid:#a70c32;--g-color-private-red-800-solid:#910f30;--g-color-private-red-850-solid:#7a112d;--g-color-private-red-900-solid:#64142a;--g-color-private-red-950-solid:#4e1727;--g-color-private-red-1000-solid:#431926;--g-color-private-purple-600-solid:#844dbb;--g-color-private-purple-650-solid:#7947aa;--g-color-private-purple-700-solid:#6e4299;--g-color-private-purple-750-solid:#633d88;--g-color-private-purple-800-solid:#593877;--g-color-private-purple-850-solid:#4e3266;--g-color-private-purple-900-solid:#432d55;--g-color-private-purple-950-solid:#382844;--g-color-private-purple-1000-solid:#32253c;--g-color-private-cool-grey-300-solid:#b5c2cc;--g-color-private-cool-grey-600-solid:#647a8d;--g-color-private-cool-grey-650-solid:#5c6f81;--g-color-private-cool-grey-700-solid:#556575;--g-color-private-cool-grey-750-solid:#4e5b69;--g-color-private-cool-grey-800-solid:#47515e;--g-color-private-cool-grey-850-solid:#3f4652;--g-color-private-cool-grey-900-solid:#383c46;--g-color-private-cool-grey-950-solid:#31323a;--g-color-private-cool-grey-1000-solid:#2d2c34;--g-color-text-primary:var(--g-color-text-dark-primary);--g-color-text-complementary:var(--g-color-text-dark-complementary);--g-color-text-secondary:var(--g-color-text-dark-secondary);--g-color-text-hint:var(--g-color-text-dark-hint);--g-color-text-info:var(--g-color-private-blue-600-solid);--g-color-text-positive:var(--g-color-private-green-600-solid);--g-color-text-warning:var(--g-color-private-yellow-700-solid);--g-color-text-danger:var(--g-color-private-red-600-solid);--g-color-text-utility:var(--g-color-private-purple-600-solid);--g-color-text-misc:var(--g-color-private-cool-grey-600-solid);--g-color-text-info-heavy:var(--g-color-private-blue-700-solid);--g-color-text-positive-heavy:var(--g-color-private-green-700-solid);--g-color-text-warning-heavy:var(--g-color-private-orange-700-solid);--g-color-text-danger-heavy:var(--g-color-private-red-700-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-700-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-700-solid);--g-color-text-brand:var(--g-color-private-yellow-700-solid);--g-color-text-brand-heavy:var(--g-color-private-orange-700-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-650-solid);--g-color-text-link-hover:var(--g-color-private-orange-650-solid);--g-color-text-link-visited:var(--g-color-private-purple-550-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-800-solid);--g-color-text-dark-primary:var(--g-color-private-black-850);--g-color-text-dark-complementary:var(--g-color-private-black-700);--g-color-text-dark-secondary:var(--g-color-private-black-500);--g-color-text-dark-hint:var(--g-color-private-black-300);--g-color-text-light-primary:var(--g-color-private-white-1000-solid);--g-color-text-light-complementary:var(--g-color-private-white-850);--g-color-text-light-secondary:var(--g-color-private-white-700);--g-color-text-light-hint:var(--g-color-private-white-500);--g-color-text-inverted-primary:var(--g-color-text-light-primary);--g-color-text-inverted-complementary:var(--g-color-text-light-complementary);--g-color-text-inverted-secondary:var(--g-color-text-light-secondary);--g-color-text-inverted-hint:var(--g-color-text-light-hint);--g-color-base-background:var(--g-color-private-white-1000-solid);--g-color-base-generic:var(--g-color-private-black-50);--g-color-base-generic-hover:var(--g-color-private-black-150);--g-color-base-generic-medium:var(--g-color-private-black-150);--g-color-base-generic-medium-hover:var(--g-color-private-black-250);--g-color-base-generic-accent:var(--g-color-private-black-150);--g-color-base-generic-accent-disabled:var(--g-color-private-black-70);--g-color-base-generic-ultralight:var(--g-color-private-black-20-solid);--g-color-base-simple-hover:var(--g-color-private-black-50);--g-color-base-simple-hover-solid:var(--g-color-private-black-50-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-600-solid);--g-color-base-selection:var(--g-color-private-yellow-200);--g-color-base-selection-hover:var(--g-color-private-yellow-300);--g-color-base-info-light:var(--g-color-private-blue-100);--g-color-base-info-light-hover:var(--g-color-private-blue-200);--g-color-base-info-medium:var(--g-color-private-blue-200);--g-color-base-info-medium-hover:var(--g-color-private-blue-300);--g-color-base-info-heavy:var(--g-color-private-blue-600-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-700-solid);--g-color-base-positive-light:var(--g-color-private-green-100);--g-color-base-positive-light-hover:var(--g-color-private-green-200);--g-color-base-positive-medium:var(--g-color-private-green-200);--g-color-base-positive-medium-hover:var(--g-color-private-green-300);--g-color-base-positive-heavy:var(--g-color-private-green-600-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-700-solid);--g-color-base-warning-light:var(--g-color-private-yellow-200);--g-color-base-warning-light-hover:var(--g-color-private-yellow-300);--g-color-base-warning-medium:var(--g-color-private-yellow-400);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-500);--g-color-base-warning-heavy:var(--g-color-private-yellow-550-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-650-solid);--g-color-base-danger-light:var(--g-color-private-red-100);--g-color-base-danger-light-hover:var(--g-color-private-red-200);--g-color-base-danger-medium:var(--g-color-private-red-200);--g-color-base-danger-medium-hover:var(--g-color-private-red-300);--g-color-base-danger-heavy:var(--g-color-private-red-600-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-700-solid);--g-color-base-utility-light:var(--g-color-private-purple-100);--g-color-base-utility-light-hover:var(--g-color-private-purple-200);--g-color-base-utility-medium:var(--g-color-private-purple-200);--g-color-base-utility-medium-hover:var(--g-color-private-purple-300);--g-color-base-utility-heavy:var(--g-color-private-purple-600-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-700-solid);--g-color-base-neutral-light:var(--g-color-private-black-50);--g-color-base-neutral-light-hover:var(--g-color-private-black-100);--g-color-base-neutral-medium:var(--g-color-private-black-200);--g-color-base-neutral-medium-hover:var(--g-color-private-black-250);--g-color-base-neutral-heavy:var(--g-color-private-black-450);--g-color-base-neutral-heavy-hover:var(--g-color-private-black-550);--g-color-base-misc-light:var(--g-color-private-cool-grey-100);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-200);--g-color-base-misc-medium:var(--g-color-private-cool-grey-200);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-300);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-600-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-700-solid);--g-color-base-light:var(--g-color-private-white-1000-solid);--g-color-base-light-hover:var(--g-color-private-white-850);--g-color-base-light-simple-hover:var(--g-color-private-white-150);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-1000-solid);--g-color-base-float-hover:var(--g-color-private-black-50-solid);--g-color-base-float-medium:var(--g-color-private-black-550-solid);--g-color-base-float-heavy:var(--g-color-private-black-700-solid);--g-color-base-float-accent:var(--g-color-private-white-1000-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-850);--g-color-base-float-announcement:var(--g-color-private-cool-grey-50-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-black-100);--g-color-line-generic-hover:var(--g-color-private-black-150);--g-color-line-generic-active:var(--g-color-private-black-300);--g-color-line-generic-accent:var(--g-color-private-black-150);--g-color-line-generic-accent-hover:var(--g-color-private-black-300);--g-color-line-generic-solid:var(--g-color-private-black-100-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-450);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-450);--g-color-line-positive:var(--g-color-private-green-450);--g-color-line-warning:var(--g-color-private-yellow-600-solid);--g-color-line-danger:var(--g-color-private-red-450);--g-color-line-utility:var(--g-color-private-purple-450);--g-color-line-misc:var(--g-color-private-cool-grey-450);--g-color-sfx-veil:var(--g-color-private-black-250);--g-color-sfx-shadow:var(--g-color-private-black-150);--g-color-sfx-shadow-heavy:var(--g-color-private-black-500);--g-color-sfx-shadow-light:var(--g-color-private-black-50);--g-color-sfx-fade:var(--g-color-private-white-300);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-black-100);--g-color-scroll-handle-hover:var(--g-color-private-black-150);--g-color-scroll-corner:var(--g-color-private-black-100);--g-color-infographics-axis:var(--g-color-private-black-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-950)}.g-root_theme_dark{--g-color-private-white-20-solid:#262226;--g-color-private-white-50-solid:#2d282d;--g-color-private-white-70-solid:#312d31;--g-color-private-white-100-solid:#383438;--g-color-private-white-150-solid:#433f43;--g-color-private-white-200-solid:#4e4a4e;--g-color-private-white-250-solid:#595559;--g-color-private-white-300-solid:#646164;--g-color-private-white-350-solid:#6f6c6f;--g-color-private-white-400-solid:#7a777a;--g-color-private-white-450-solid:#858385;--g-color-private-white-500-solid:#908e90;--g-color-private-white-550-solid:#9c999c;--g-color-private-white-600-solid:#a7a5a7;--g-color-private-white-650-solid:#b2b0b2;--g-color-private-white-700-solid:#bdbbbd;--g-color-private-white-750-solid:#c8c6c8;--g-color-private-white-800-solid:#d3d2d3;--g-color-private-white-850-solid:#deddde;--g-color-private-white-900-solid:#e9e8e9;--g-color-private-white-950-solid:#f4f4f4;--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#242937;--g-color-private-blue-100-solid:#252f41;--g-color-private-blue-150-solid:#26354b;--g-color-private-blue-200-solid:#284260;--g-color-private-blue-250-solid:#2a4e75;--g-color-private-blue-300-solid:#2c5a8a;--g-color-private-blue-350-solid:#2e669e;--g-color-private-blue-400-solid:#3072b3;--g-color-private-blue-450-solid:#327fc8;--g-color-private-blue-500-solid:#348bdc;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#4aa1f2;--g-color-private-blue-650-solid:#5eacf4;--g-color-private-blue-700-solid:#72b6f5;--g-color-private-blue-750-solid:#86c1f7;--g-color-private-blue-800-solid:#9bcbf8;--g-color-private-blue-850-solid:#afd5f9;--g-color-private-blue-900-solid:#c3e0fb;--g-color-private-blue-950-solid:#d7eafc;--g-color-private-blue-1000-solid:#e1effd;--g-color-private-green-50:#4db09b1a;--g-color-private-green-100:#4db09b26;--g-color-private-green-150:#4db09b33;--g-color-private-green-200:#4db09b4d;--g-color-private-green-250:#4db09b66;--g-color-private-green-300:#4db09b80;--g-color-private-green-350:#4db09b99;--g-color-private-green-400:#4db09bb3;--g-color-private-green-450:#4db09bcc;--g-color-private-green-500:#4db09be6;--g-color-private-green-50-solid:#262c2e;--g-color-private-green-100-solid:#283334;--g-color-private-green-150-solid:#2b3a3a;--g-color-private-green-200-solid:#2f4946;--g-color-private-green-250-solid:#335852;--g-color-private-green-300-solid:#38675f;--g-color-private-green-350-solid:#3c756b;--g-color-private-green-400-solid:#408477;--g-color-private-green-450-solid:#449383;--g-color-private-green-500-solid:#49a18f;--g-color-private-green-550-solid:#4db09b;--g-color-private-green-600-solid:#5fb8a5;--g-color-private-green-650-solid:#71c0af;--g-color-private-green-700-solid:#82c8b9;--g-color-private-green-750-solid:#94d0c3;--g-color-private-green-800-solid:#a6d8cd;--g-color-private-green-850-solid:#b8dfd7;--g-color-private-green-900-solid:#cae7e1;--g-color-private-green-950-solid:#dbefeb;--g-color-private-green-1000-solid:#e4f3f0;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#382d28;--g-color-private-yellow-100-solid:#43352b;--g-color-private-yellow-150-solid:#4e3d2e;--g-color-private-yellow-200-solid:#644d33;--g-color-private-yellow-250-solid:#7a5d39;--g-color-private-yellow-300-solid:#916e3f;--g-color-private-yellow-350-solid:#a77e45;--g-color-private-yellow-400-solid:#bd8e4b;--g-color-private-yellow-450-solid:#d39e50;--g-color-private-yellow-500-solid:#e9ae56;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#ffc56c;--g-color-private-yellow-650-solid:#ffcb7d;--g-color-private-yellow-700-solid:#ffd28d;--g-color-private-yellow-750-solid:#ffd89d;--g-color-private-yellow-800-solid:#ffdfae;--g-color-private-yellow-850-solid:#ffe5be;--g-color-private-yellow-900-solid:#ffecce;--g-color-private-yellow-950-solid:#fff2de;--g-color-private-yellow-1000-solid:#fff5e7;--g-color-private-orange-50-solid:#332420;--g-color-private-orange-100-solid:#3b281f;--g-color-private-orange-150-solid:#432b1e;--g-color-private-orange-200-solid:#54321b;--g-color-private-orange-250-solid:#643919;--g-color-private-orange-300-solid:#754017;--g-color-private-orange-350-solid:#864715;--g-color-private-orange-400-solid:#964e13;--g-color-private-orange-450-solid:#a75510;--g-color-private-orange-500-solid:#b75c0e;--g-color-private-orange-700-solid:#d99255;--g-color-private-orange-800-solid:#e4b186;--g-color-private-red-50:#e5325d1a;--g-color-private-red-100:#e5325d26;--g-color-private-red-150:#e5325d33;--g-color-private-red-200:#e5325d4d;--g-color-private-red-250:#e5325d66;--g-color-private-red-300:#e5325d80;--g-color-private-red-350:#e5325d99;--g-color-private-red-400:#e5325db3;--g-color-private-red-450:#e5325dcc;--g-color-private-red-500:#e5325de6;--g-color-private-red-50-solid:#361f28;--g-color-private-red-100-solid:#3f202b;--g-color-private-red-150-solid:#49212e;--g-color-private-red-200-solid:#5d2334;--g-color-private-red-250-solid:#70253a;--g-color-private-red-300-solid:#842840;--g-color-private-red-350-solid:#972a45;--g-color-private-red-400-solid:#ab2c4b;--g-color-private-red-450-solid:#be2e51;--g-color-private-red-500-solid:#d23057;--g-color-private-red-550-solid:#e5325d;--g-color-private-red-600-solid:#e8476d;--g-color-private-red-650-solid:#ea5b7d;--g-color-private-red-700-solid:#ed708e;--g-color-private-red-750-solid:#ef849e;--g-color-private-red-800-solid:#f299ae;--g-color-private-red-850-solid:#f5adbe;--g-color-private-red-900-solid:#f7c2ce;--g-color-private-red-950-solid:#fad6df;--g-color-private-red-1000-solid:#fbe0e7;--g-color-private-purple-50-solid:#2d2233;--g-color-private-purple-100-solid:#32253c;--g-color-private-purple-150-solid:#382844;--g-color-private-purple-200-solid:#432d55;--g-color-private-purple-250-solid:#4e3266;--g-color-private-purple-300-solid:#593877;--g-color-private-purple-350-solid:#633d88;--g-color-private-purple-400-solid:#6e4299;--g-color-private-purple-450-solid:#7947aa;--g-color-private-purple-500-solid:#844dbb;--g-color-private-cool-grey-50-solid:#28272e;--g-color-private-cool-grey-100-solid:#2b2c34;--g-color-private-cool-grey-150-solid:#2e313a;--g-color-private-cool-grey-200-solid:#353b47;--g-color-private-cool-grey-250-solid:#3b4553;--g-color-private-cool-grey-300-solid:#414f5f;--g-color-private-cool-grey-350-solid:#47586b;--g-color-private-cool-grey-400-solid:#4d6277;--g-color-private-cool-grey-450-solid:#546c84;--g-color-private-cool-grey-500-solid:#5a7690;--g-color-private-cool-grey-750-solid:#a0b3c4;--g-color-private-cool-grey-800-solid:#b0c0ce;--g-color-text-primary:var(--g-color-text-light-primary);--g-color-text-complementary:var(--g-color-text-light-complementary);--g-color-text-secondary:var(--g-color-text-light-secondary);--g-color-text-hint:var(--g-color-text-light-hint);--g-color-text-info:var(--g-color-private-blue-550-solid);--g-color-text-positive:var(--g-color-private-green-550-solid);--g-color-text-warning:var(--g-color-private-yellow-550-solid);--g-color-text-danger:var(--g-color-private-red-550-solid);--g-color-text-utility:var(--g-color-private-purple-600-solid);--g-color-text-misc:var(--g-color-private-cool-grey-600-solid);--g-color-text-info-heavy:var(--g-color-private-blue-600-solid);--g-color-text-positive-heavy:var(--g-color-private-green-600-solid);--g-color-text-warning-heavy:var(--g-color-private-yellow-600-solid);--g-color-text-danger-heavy:var(--g-color-private-red-600-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-650-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-650-solid);--g-color-text-brand:var(--g-color-private-yellow-600-solid);--g-color-text-brand-heavy:var(--g-color-private-yellow-700-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-550-solid);--g-color-text-link-hover:var(--g-color-private-orange-550-solid);--g-color-text-link-visited:var(--g-color-private-purple-600-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-750-solid);--g-color-text-dark-primary:var(--g-color-private-black-900);--g-color-text-dark-complementary:var(--g-color-private-black-700);--g-color-text-dark-secondary:var(--g-color-private-black-500);--g-color-text-dark-hint:var(--g-color-private-black-300);--g-color-text-light-primary:var(--g-color-private-white-850);--g-color-text-light-complementary:var(--g-color-private-white-700);--g-color-text-light-secondary:var(--g-color-private-white-500);--g-color-text-light-hint:var(--g-color-private-white-300);--g-color-text-inverted-primary:var(--g-color-text-dark-primary);--g-color-text-inverted-complementary:var(--g-color-text-dark-complementary);--g-color-text-inverted-secondary:var(--g-color-text-dark-secondary);--g-color-text-inverted-hint:var(--g-color-text-dark-hint);--g-color-base-background:#221d22;--g-color-base-generic:var(--g-color-private-white-100);--g-color-base-generic-hover:var(--g-color-private-white-150);--g-color-base-generic-medium:var(--g-color-private-white-250);--g-color-base-generic-medium-hover:var(--g-color-private-white-300);--g-color-base-generic-accent:var(--g-color-private-white-150);--g-color-base-generic-accent-disabled:var(--g-color-private-white-70);--g-color-base-generic-ultralight:var(--g-color-private-white-20-solid);--g-color-base-simple-hover:var(--g-color-private-white-100);--g-color-base-simple-hover-solid:var(--g-color-private-white-100-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-650-solid);--g-color-base-selection:var(--g-color-private-yellow-150);--g-color-base-selection-hover:var(--g-color-private-yellow-200);--g-color-base-info-light:var(--g-color-private-blue-150);--g-color-base-info-light-hover:var(--g-color-private-blue-200);--g-color-base-info-medium:var(--g-color-private-blue-300);--g-color-base-info-medium-hover:var(--g-color-private-blue-400);--g-color-base-info-heavy:var(--g-color-private-blue-600-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-700-solid);--g-color-base-positive-light:var(--g-color-private-green-150);--g-color-base-positive-light-hover:var(--g-color-private-green-200);--g-color-base-positive-medium:var(--g-color-private-green-300);--g-color-base-positive-medium-hover:var(--g-color-private-green-400);--g-color-base-positive-heavy:var(--g-color-private-green-600-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-700-solid);--g-color-base-warning-light:var(--g-color-private-yellow-150);--g-color-base-warning-light-hover:var(--g-color-private-yellow-200);--g-color-base-warning-medium:var(--g-color-private-yellow-300);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-400);--g-color-base-warning-heavy:var(--g-color-private-yellow-600-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-700-solid);--g-color-base-danger-light:var(--g-color-private-red-150);--g-color-base-danger-light-hover:var(--g-color-private-red-200);--g-color-base-danger-medium:var(--g-color-private-red-300);--g-color-base-danger-medium-hover:var(--g-color-private-red-400);--g-color-base-danger-heavy:var(--g-color-private-red-600-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-700-solid);--g-color-base-utility-light:var(--g-color-private-purple-150);--g-color-base-utility-light-hover:var(--g-color-private-purple-250);--g-color-base-utility-medium:var(--g-color-private-purple-300);--g-color-base-utility-medium-hover:var(--g-color-private-purple-400);--g-color-base-utility-heavy:var(--g-color-private-purple-600-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-700-solid);--g-color-base-neutral-light:var(--g-color-private-white-100);--g-color-base-neutral-light-hover:var(--g-color-private-white-150);--g-color-base-neutral-medium:var(--g-color-private-white-250);--g-color-base-neutral-medium-hover:var(--g-color-private-white-350);--g-color-base-neutral-heavy:var(--g-color-private-white-550);--g-color-base-neutral-heavy-hover:var(--g-color-private-white-650);--g-color-base-misc-light:var(--g-color-private-cool-grey-150);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-200);--g-color-base-misc-medium:var(--g-color-private-cool-grey-300);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-400);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-600-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-700-solid);--g-color-base-light:var(--g-color-private-white-850);--g-color-base-light-hover:var(--g-color-private-white-700);--g-color-base-light-simple-hover:var(--g-color-private-white-150);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-100-solid);--g-color-base-float-hover:var(--g-color-private-white-150-solid);--g-color-base-float-medium:var(--g-color-private-white-150-solid);--g-color-base-float-heavy:var(--g-color-private-white-250-solid);--g-color-base-float-accent:var(--g-color-private-white-150-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-200-solid);--g-color-base-float-announcement:var(--g-color-private-white-150-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-white-150);--g-color-line-generic-hover:var(--g-color-private-white-250);--g-color-line-generic-active:var(--g-color-private-white-300);--g-color-line-generic-accent:var(--g-color-private-white-150);--g-color-line-generic-accent-hover:var(--g-color-private-white-300);--g-color-line-generic-solid:var(--g-color-private-white-150-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-450);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-450);--g-color-line-positive:var(--g-color-private-green-450);--g-color-line-warning:var(--g-color-private-yellow-450);--g-color-line-danger:var(--g-color-private-red-450);--g-color-line-utility:var(--g-color-private-purple-450);--g-color-line-misc:var(--g-color-private-cool-grey-450);--g-color-sfx-veil:var(--g-color-private-black-600);--g-color-sfx-shadow:var(--g-color-private-black-200);--g-color-sfx-shadow-heavy:var(--g-color-private-black-500);--g-color-sfx-shadow-light:var(--g-color-private-black-200);--g-color-sfx-fade:var(--g-color-private-white-250);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-white-150);--g-color-scroll-handle-hover:var(--g-color-private-white-250);--g-color-scroll-corner:var(--g-color-private-white-150);--g-color-infographics-axis:var(--g-color-private-white-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-opaque-150)}.g-root_theme_light-hc{--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#ebf5fe;--g-color-private-blue-100-solid:#e1effd;--g-color-private-blue-150-solid:#d7eafc;--g-color-private-blue-200-solid:#c3e0fb;--g-color-private-blue-250-solid:#afd5f9;--g-color-private-blue-300-solid:#9bcbf8;--g-color-private-blue-350-solid:#86c1f7;--g-color-private-blue-400-solid:#72b6f5;--g-color-private-blue-450-solid:#5eacf4;--g-color-private-blue-500-solid:#4aa1f2;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#328adb;--g-color-private-blue-650-solid:#2f7cc4;--g-color-private-blue-700-solid:#2b6fae;--g-color-private-blue-750-solid:#286198;--g-color-private-blue-800-solid:#245482;--g-color-private-blue-850-solid:#20476b;--g-color-private-blue-900-solid:#1d3955;--g-color-private-blue-950-solid:#192c3f;--g-color-private-blue-1000-solid:#172533;--g-color-private-green-50:#32ba761a;--g-color-private-green-100:#32ba7626;--g-color-private-green-150:#32ba7633;--g-color-private-green-200:#32ba764d;--g-color-private-green-250:#32ba7666;--g-color-private-green-300:#32ba7680;--g-color-private-green-350:#32ba7699;--g-color-private-green-400:#32ba76b3;--g-color-private-green-450:#32ba76cc;--g-color-private-green-500:#32ba76e6;--g-color-private-green-50-solid:#ebf8f1;--g-color-private-green-100-solid:#e0f5ea;--g-color-private-green-150-solid:#d6f1e4;--g-color-private-green-200-solid:#c2ead6;--g-color-private-green-250-solid:#ade3c8;--g-color-private-green-300-solid:#9db;--g-color-private-green-350-solid:#84d6ad;--g-color-private-green-400-solid:#70cf9f;--g-color-private-green-450-solid:#5bc891;--g-color-private-green-500-solid:#47c184;--g-color-private-green-550-solid:#32ba76;--g-color-private-green-600-solid:#2fa96c;--g-color-private-green-650-solid:#2c9862;--g-color-private-green-700-solid:#288758;--g-color-private-green-750-solid:#25764e;--g-color-private-green-800-solid:#264;--g-color-private-green-850-solid:#1f553a;--g-color-private-green-900-solid:#1c4430;--g-color-private-green-950-solid:#183326;--g-color-private-green-1000-solid:#172a21;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#fff9ef;--g-color-private-yellow-100-solid:#fff5e7;--g-color-private-yellow-150-solid:#fff2de;--g-color-private-yellow-200-solid:#ffecce;--g-color-private-yellow-250-solid:#ffe5be;--g-color-private-yellow-300-solid:#ffdfae;--g-color-private-yellow-350-solid:#ffd89d;--g-color-private-yellow-400-solid:#ffd28d;--g-color-private-yellow-450-solid:#ffcb7d;--g-color-private-yellow-500-solid:#ffc56c;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#e7ad55;--g-color-private-yellow-650-solid:#d09b4d;--g-color-private-yellow-700-solid:#b88a46;--g-color-private-yellow-750-solid:#a0793e;--g-color-private-yellow-800-solid:#896837;--g-color-private-yellow-850-solid:#715630;--g-color-private-yellow-900-solid:#594528;--g-color-private-yellow-950-solid:#413421;--g-color-private-yellow-1000-solid:#362b1d;--g-color-private-orange-400-solid:#ffa04d;--g-color-private-orange-500-solid:#ff8519;--g-color-private-orange-600-solid:#e76d02;--g-color-private-orange-650-solid:#d06304;--g-color-private-orange-700-solid:#b85805;--g-color-private-orange-750-solid:#a04e07;--g-color-private-orange-800-solid:#894409;--g-color-private-orange-850-solid:#713a0b;--g-color-private-orange-900-solid:#59300d;--g-color-private-orange-950-solid:#41250e;--g-color-private-orange-1000-solid:#36200f;--g-color-private-red-50:#ff003d1a;--g-color-private-red-100:#ff003d26;--g-color-private-red-150:#ff003d33;--g-color-private-red-200:#ff003d4d;--g-color-private-red-250:#ff003d66;--g-color-private-red-300:#ff003d80;--g-color-private-red-350:#ff003d99;--g-color-private-red-400:#ff003db3;--g-color-private-red-450:#ff003dcc;--g-color-private-red-500:#ff003de6;--g-color-private-red-50-solid:#ffe6ec;--g-color-private-red-100-solid:#ffd9e2;--g-color-private-red-150-solid:#ffccd8;--g-color-private-red-200-solid:#ffb3c5;--g-color-private-red-250-solid:#ff99b1;--g-color-private-red-300-solid:#ff809e;--g-color-private-red-350-solid:#ff668b;--g-color-private-red-400-solid:#ff4d77;--g-color-private-red-450-solid:#ff3364;--g-color-private-red-500-solid:#ff1950;--g-color-private-red-550-solid:#ff003d;--g-color-private-red-600-solid:#e70239;--g-color-private-red-650-solid:#d00334;--g-color-private-red-700-solid:#b80530;--g-color-private-red-750-solid:#a0072c;--g-color-private-red-800-solid:#890928;--g-color-private-red-850-solid:#710a23;--g-color-private-red-900-solid:#590c1f;--g-color-private-red-950-solid:#410e1b;--g-color-private-red-1000-solid:#360e18;--g-color-private-purple-600-solid:#834cb9;--g-color-private-purple-650-solid:#7645a7;--g-color-private-purple-700-solid:#6a3f94;--g-color-private-purple-750-solid:#5d3882;--g-color-private-purple-800-solid:#51326f;--g-color-private-purple-850-solid:#442b5c;--g-color-private-purple-900-solid:#38254a;--g-color-private-purple-950-solid:#2b1e37;--g-color-private-purple-1000-solid:#251b2e;--g-color-private-cool-grey-300-solid:#b5c2cc;--g-color-private-cool-grey-600-solid:#62798c;--g-color-private-cool-grey-650-solid:#596d7e;--g-color-private-cool-grey-700-solid:#506271;--g-color-private-cool-grey-750-solid:#475663;--g-color-private-cool-grey-800-solid:#3f4b56;--g-color-private-cool-grey-850-solid:#363f48;--g-color-private-cool-grey-900-solid:#2d343b;--g-color-private-cool-grey-950-solid:#24282d;--g-color-private-cool-grey-1000-solid:#1f2226;--g-color-text-primary:var(--g-color-text-dark-primary);--g-color-text-complementary:var(--g-color-text-dark-complementary);--g-color-text-secondary:var(--g-color-text-dark-secondary);--g-color-text-hint:var(--g-color-text-dark-hint);--g-color-text-info:var(--g-color-private-blue-650-solid);--g-color-text-positive:var(--g-color-private-green-650-solid);--g-color-text-warning:var(--g-color-private-yellow-700-solid);--g-color-text-danger:var(--g-color-private-red-650-solid);--g-color-text-utility:var(--g-color-private-purple-650-solid);--g-color-text-misc:var(--g-color-private-cool-grey-650-solid);--g-color-text-info-heavy:var(--g-color-private-blue-900-solid);--g-color-text-positive-heavy:var(--g-color-private-green-900-solid);--g-color-text-warning-heavy:var(--g-color-private-orange-900-solid);--g-color-text-danger-heavy:var(--g-color-private-red-900-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-900-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-900-solid);--g-color-text-brand:var(--g-color-private-yellow-700-solid);--g-color-text-brand-heavy:var(--g-color-private-orange-900-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-700-solid);--g-color-text-link-hover:var(--g-color-private-orange-700-solid);--g-color-text-link-visited:var(--g-color-private-purple-600-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-850-solid);--g-color-text-dark-primary:var(--g-color-private-black-1000-solid);--g-color-text-dark-complementary:var(--g-color-private-black-850);--g-color-text-dark-secondary:var(--g-color-private-black-700);--g-color-text-dark-hint:var(--g-color-private-black-500);--g-color-text-light-primary:var(--g-color-private-white-1000-solid);--g-color-text-light-complementary:var(--g-color-private-white-850);--g-color-text-light-secondary:var(--g-color-private-white-700);--g-color-text-light-hint:var(--g-color-private-white-500);--g-color-text-inverted-primary:var(--g-color-text-light-primary);--g-color-text-inverted-complementary:var(--g-color-text-light-complementary);--g-color-text-inverted-secondary:var(--g-color-text-light-secondary);--g-color-text-inverted-hint:var(--g-color-text-light-hint);--g-color-base-background:var(--g-color-private-white-1000-solid);--g-color-base-generic:var(--g-color-private-black-150);--g-color-base-generic-hover:var(--g-color-private-black-300);--g-color-base-generic-medium:var(--g-color-private-black-250);--g-color-base-generic-medium-hover:var(--g-color-private-black-350);--g-color-base-generic-accent:var(--g-color-private-black-250);--g-color-base-generic-accent-disabled:var(--g-color-private-black-150);--g-color-base-generic-ultralight:var(--g-color-private-black-50-solid);--g-color-base-simple-hover:var(--g-color-private-black-150);--g-color-base-simple-hover-solid:var(--g-color-private-black-150-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-650-solid);--g-color-base-selection:var(--g-color-private-yellow-300);--g-color-base-selection-hover:var(--g-color-private-yellow-400);--g-color-base-info-light:var(--g-color-private-blue-250);--g-color-base-info-light-hover:var(--g-color-private-blue-350);--g-color-base-info-medium:var(--g-color-private-blue-400);--g-color-base-info-medium-hover:var(--g-color-private-blue-500);--g-color-base-info-heavy:var(--g-color-private-blue-700-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-850-solid);--g-color-base-positive-light:var(--g-color-private-green-250);--g-color-base-positive-light-hover:var(--g-color-private-green-350);--g-color-base-positive-medium:var(--g-color-private-green-400);--g-color-base-positive-medium-hover:var(--g-color-private-green-500);--g-color-base-positive-heavy:var(--g-color-private-green-700-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-800-solid);--g-color-base-warning-light:var(--g-color-private-yellow-300);--g-color-base-warning-light-hover:var(--g-color-private-yellow-400);--g-color-base-warning-medium:var(--g-color-private-yellow-400);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-550-solid);--g-color-base-warning-heavy:var(--g-color-private-yellow-600-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-700-solid);--g-color-base-danger-light:var(--g-color-private-red-250);--g-color-base-danger-light-hover:var(--g-color-private-red-350);--g-color-base-danger-medium:var(--g-color-private-red-400);--g-color-base-danger-medium-hover:var(--g-color-private-red-500);--g-color-base-danger-heavy:var(--g-color-private-red-700-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-800-solid);--g-color-base-utility-light:var(--g-color-private-purple-250);--g-color-base-utility-light-hover:var(--g-color-private-purple-350);--g-color-base-utility-medium:var(--g-color-private-purple-400);--g-color-base-utility-medium-hover:var(--g-color-private-purple-500);--g-color-base-utility-heavy:var(--g-color-private-purple-700-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-800-solid);--g-color-base-neutral-light:var(--g-color-private-black-150);--g-color-base-neutral-light-hover:var(--g-color-private-black-250);--g-color-base-neutral-medium:var(--g-color-private-black-300);--g-color-base-neutral-medium-hover:var(--g-color-private-black-400);--g-color-base-neutral-heavy:var(--g-color-private-black-550);--g-color-base-neutral-heavy-hover:var(--g-color-private-black-650);--g-color-base-misc-light:var(--g-color-private-cool-grey-250);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-350);--g-color-base-misc-medium:var(--g-color-private-cool-grey-400);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-500);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-700-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-800-solid);--g-color-base-light:var(--g-color-private-white-1000-solid);--g-color-base-light-hover:var(--g-color-private-white-850);--g-color-base-light-simple-hover:var(--g-color-private-white-300);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-1000-solid);--g-color-base-float-hover:var(--g-color-private-black-150-solid);--g-color-base-float-medium:var(--g-color-private-black-550-solid);--g-color-base-float-heavy:var(--g-color-private-black-700-solid);--g-color-base-float-accent:var(--g-color-private-white-1000-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-850);--g-color-base-float-announcement:var(--g-color-private-cool-grey-150-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-black-200);--g-color-line-generic-hover:var(--g-color-private-black-400);--g-color-line-generic-active:var(--g-color-private-black-700);--g-color-line-generic-accent:var(--g-color-private-black-300);--g-color-line-generic-accent-hover:var(--g-color-private-black-700);--g-color-line-generic-solid:var(--g-color-private-black-200-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-450);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-450);--g-color-line-positive:var(--g-color-private-green-450);--g-color-line-warning:var(--g-color-private-yellow-600-solid);--g-color-line-danger:var(--g-color-private-red-450);--g-color-line-utility:var(--g-color-private-purple-450);--g-color-line-misc:var(--g-color-private-cool-grey-450);--g-color-sfx-veil:var(--g-color-private-black-450);--g-color-sfx-shadow:var(--g-color-private-black-300);--g-color-sfx-shadow-heavy:var(--g-color-private-black-600);--g-color-sfx-shadow-light:var(--g-color-private-black-100);--g-color-sfx-fade:var(--g-color-private-white-300);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-black-100);--g-color-scroll-handle-hover:var(--g-color-private-black-150);--g-color-scroll-corner:var(--g-color-private-black-100);--g-color-infographics-axis:var(--g-color-private-black-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-950)}.g-root_theme_dark-hc{--g-color-private-white-50-solid:#1e1d1e;--g-color-private-white-70-solid:#232223;--g-color-private-white-100-solid:#2a292a;--g-color-private-white-150-solid:#363536;--g-color-private-white-200-solid:#414141;--g-color-private-white-250-solid:#4d4d4d;--g-color-private-white-300-solid:#595859;--g-color-private-white-350-solid:#656465;--g-color-private-white-400-solid:#717071;--g-color-private-white-450-solid:#7d7c7d;--g-color-private-white-500-solid:#888;--g-color-private-white-550-solid:#949494;--g-color-private-white-600-solid:#a0a0a0;--g-color-private-white-650-solid:#acacac;--g-color-private-white-700-solid:#b8b8b8;--g-color-private-white-750-solid:#c4c3c4;--g-color-private-white-800-solid:#d0cfd0;--g-color-private-white-850-solid:#d0cfd0;--g-color-private-white-900-solid:#e7e7e7;--g-color-private-white-950-solid:#f3f3f3;--g-color-private-blue-50:#3697f11a;--g-color-private-blue-100:#3697f126;--g-color-private-blue-150:#3697f133;--g-color-private-blue-200:#3697f14d;--g-color-private-blue-250:#3697f166;--g-color-private-blue-300:#3697f180;--g-color-private-blue-350:#3697f199;--g-color-private-blue-400:#3697f1b3;--g-color-private-blue-450:#3697f1cc;--g-color-private-blue-500:#3697f1e6;--g-color-private-blue-50-solid:#161e28;--g-color-private-blue-100-solid:#172533;--g-color-private-blue-150-solid:#192c3f;--g-color-private-blue-200-solid:#1d3955;--g-color-private-blue-250-solid:#20476b;--g-color-private-blue-300-solid:#245482;--g-color-private-blue-350-solid:#286198;--g-color-private-blue-400-solid:#2b6fae;--g-color-private-blue-450-solid:#2f7cc4;--g-color-private-blue-500-solid:#328adb;--g-color-private-blue-550-solid:#3697f1;--g-color-private-blue-600-solid:#4aa1f2;--g-color-private-blue-650-solid:#5eacf4;--g-color-private-blue-700-solid:#72b6f5;--g-color-private-blue-750-solid:#86c1f7;--g-color-private-blue-800-solid:#9bcbf8;--g-color-private-blue-850-solid:#afd5f9;--g-color-private-blue-900-solid:#c3e0fb;--g-color-private-blue-950-solid:#d7eafc;--g-color-private-blue-1000-solid:#e1effd;--g-color-private-green-50:#4db09b1a;--g-color-private-green-100:#4db09b26;--g-color-private-green-150:#4db09b33;--g-color-private-green-200:#4db09b4d;--g-color-private-green-250:#4db09b66;--g-color-private-green-300:#4db09b80;--g-color-private-green-350:#4db09b99;--g-color-private-green-400:#4db09bb3;--g-color-private-green-450:#4db09bcc;--g-color-private-green-500:#4db09be6;--g-color-private-green-50-solid:#182120;--g-color-private-green-100-solid:#1b2927;--g-color-private-green-150-solid:#1e312d;--g-color-private-green-200-solid:#24413b;--g-color-private-green-250-solid:#2a5149;--g-color-private-green-300-solid:#306157;--g-color-private-green-350-solid:#357064;--g-color-private-green-400-solid:#3b8072;--g-color-private-green-450-solid:#419080;--g-color-private-green-500-solid:#47a08d;--g-color-private-green-550-solid:#4db09b;--g-color-private-green-600-solid:#5fb8a5;--g-color-private-green-650-solid:#71c0af;--g-color-private-green-700-solid:#82c8b9;--g-color-private-green-750-solid:#94d0c3;--g-color-private-green-800-solid:#a6d8cd;--g-color-private-green-850-solid:#b8dfd7;--g-color-private-green-900-solid:#cae7e1;--g-color-private-green-950-solid:#dbefeb;--g-color-private-green-1000-solid:#e4f3f0;--g-color-private-yellow-50:#ffbe5c1a;--g-color-private-yellow-100:#ffbe5c26;--g-color-private-yellow-150:#ffbe5c33;--g-color-private-yellow-200:#ffbe5c4d;--g-color-private-yellow-250:#ffbe5c66;--g-color-private-yellow-300:#ffbe5c80;--g-color-private-yellow-350:#ffbe5c99;--g-color-private-yellow-400:#ffbe5cb3;--g-color-private-yellow-450:#ffbe5ccc;--g-color-private-yellow-500:#ffbe5ce6;--g-color-private-yellow-50-solid:#2a2219;--g-color-private-yellow-100-solid:#362b1d;--g-color-private-yellow-150-solid:#413421;--g-color-private-yellow-200-solid:#594528;--g-color-private-yellow-250-solid:#715630;--g-color-private-yellow-300-solid:#896837;--g-color-private-yellow-350-solid:#a0793e;--g-color-private-yellow-400-solid:#b88a46;--g-color-private-yellow-450-solid:#d09b4d;--g-color-private-yellow-500-solid:#e7ad55;--g-color-private-yellow-550-solid:#ffbe5c;--g-color-private-yellow-600-solid:#ffc56c;--g-color-private-yellow-650-solid:#ffcb7d;--g-color-private-yellow-700-solid:#ffd28d;--g-color-private-yellow-750-solid:#ffd89d;--g-color-private-yellow-800-solid:#ffdfae;--g-color-private-yellow-850-solid:#ffe5be;--g-color-private-yellow-900-solid:#ffecce;--g-color-private-yellow-950-solid:#fff2de;--g-color-private-yellow-1000-solid:#fff5e7;--g-color-private-orange-50-solid:#241911;--g-color-private-orange-100-solid:#2d1d11;--g-color-private-orange-150-solid:#362111;--g-color-private-orange-200-solid:#492a10;--g-color-private-orange-250-solid:#5b3210;--g-color-private-orange-300-solid:#6d3a0f;--g-color-private-orange-350-solid:#7f420e;--g-color-private-orange-400-solid:#914a0e;--g-color-private-orange-450-solid:#a4530d;--g-color-private-orange-500-solid:#b65b0d;--g-color-private-orange-700-solid:#d99255;--g-color-private-orange-800-solid:#e4b186;--g-color-private-red-50:#e5325d1a;--g-color-private-red-100:#e5325d26;--g-color-private-red-150:#e5325d33;--g-color-private-red-200:#e5325d4d;--g-color-private-red-250:#e5325d66;--g-color-private-red-300:#e5325d80;--g-color-private-red-350:#e5325d99;--g-color-private-red-400:#e5325db3;--g-color-private-red-450:#e5325dcc;--g-color-private-red-500:#e5325de6;--g-color-private-red-50-solid:#27141a;--g-color-private-red-100-solid:#32161d;--g-color-private-red-150-solid:#3c1821;--g-color-private-red-200-solid:#511b29;--g-color-private-red-250-solid:#661e30;--g-color-private-red-300-solid:#7c2238;--g-color-private-red-350-solid:#91253f;--g-color-private-red-400-solid:#a62847;--g-color-private-red-450-solid:#bb2b4e;--g-color-private-red-500-solid:#d02f56;--g-color-private-red-550-solid:#e5325d;--g-color-private-red-600-solid:#e8476d;--g-color-private-red-650-solid:#ea5b7d;--g-color-private-red-700-solid:#ed708e;--g-color-private-red-750-solid:#ef849e;--g-color-private-red-800-solid:#f299ae;--g-color-private-red-850-solid:#f5adbe;--g-color-private-red-900-solid:#f7c2ce;--g-color-private-red-950-solid:#fad6df;--g-color-private-red-1000-solid:#fbe0e7;--g-color-private-purple-50-solid:#1f1825;--g-color-private-purple-100-solid:#251b2e;--g-color-private-purple-150-solid:#2b1e37;--g-color-private-purple-200-solid:#38254a;--g-color-private-purple-250-solid:#442b5c;--g-color-private-purple-300-solid:#51326f;--g-color-private-purple-350-solid:#5d3882;--g-color-private-purple-400-solid:#6a3f94;--g-color-private-purple-450-solid:#7645a7;--g-color-private-purple-500-solid:#834cb9;--g-color-private-cool-grey-50-solid:#1a1c20;--g-color-private-cool-grey-100-solid:#1e2227;--g-color-private-cool-grey-150-solid:#22272e;--g-color-private-cool-grey-200-solid:#29323b;--g-color-private-cool-grey-250-solid:#313d49;--g-color-private-cool-grey-300-solid:#394957;--g-color-private-cool-grey-350-solid:#415465;--g-color-private-cool-grey-400-solid:#495f73;--g-color-private-cool-grey-450-solid:#506a80;--g-color-private-cool-grey-500-solid:#58758e;--g-color-private-cool-grey-750-solid:#a0b3c4;--g-color-private-cool-grey-800-solid:#b0c0ce;--g-color-text-primary:var(--g-color-text-light-primary);--g-color-text-complementary:var(--g-color-text-light-complementary);--g-color-text-secondary:var(--g-color-text-light-secondary);--g-color-text-hint:var(--g-color-text-light-hint);--g-color-text-info:var(--g-color-private-blue-650-solid);--g-color-text-positive:var(--g-color-private-green-650-solid);--g-color-text-warning:var(--g-color-private-yellow-650-solid);--g-color-text-danger:var(--g-color-private-red-650-solid);--g-color-text-utility:var(--g-color-private-purple-650-solid);--g-color-text-misc:var(--g-color-private-cool-grey-650-solid);--g-color-text-info-heavy:var(--g-color-private-blue-850-solid);--g-color-text-positive-heavy:var(--g-color-private-green-850-solid);--g-color-text-warning-heavy:var(--g-color-private-yellow-850-solid);--g-color-text-danger-heavy:var(--g-color-private-red-850-solid);--g-color-text-utility-heavy:var(--g-color-private-purple-850-solid);--g-color-text-misc-heavy:var(--g-color-private-cool-grey-850-solid);--g-color-text-brand:var(--g-color-private-yellow-600-solid);--g-color-text-brand-heavy:var(--g-color-private-yellow-700-solid);--g-color-text-brand-contrast:var(--g-color-text-dark-primary);--g-color-text-link:var(--g-color-private-yellow-550-solid);--g-color-text-link-hover:var(--g-color-private-orange-550-solid);--g-color-text-link-visited:var(--g-color-private-purple-650-solid);--g-color-text-link-visited-hover:var(--g-color-private-purple-800-solid);--g-color-text-dark-primary:var(--g-color-private-black-1000-solid);--g-color-text-dark-complementary:var(--g-color-private-black-800);--g-color-text-dark-secondary:var(--g-color-private-black-600);--g-color-text-dark-hint:var(--g-color-private-black-400);--g-color-text-light-primary:var(--g-color-private-white-1000-solid);--g-color-text-light-complementary:var(--g-color-private-white-800);--g-color-text-light-secondary:var(--g-color-private-white-600);--g-color-text-light-hint:var(--g-color-private-white-400);--g-color-text-inverted-primary:var(--g-color-text-dark-primary);--g-color-text-inverted-complementary:var(--g-color-text-dark-complementary);--g-color-text-inverted-secondary:var(--g-color-text-dark-secondary);--g-color-text-inverted-hint:var(--g-color-text-dark-hint);--g-color-base-background:#121112;--g-color-base-generic:var(--g-color-private-white-100);--g-color-base-generic-hover:var(--g-color-private-white-250);--g-color-base-generic-medium:var(--g-color-private-white-250);--g-color-base-generic-medium-hover:var(--g-color-private-white-400);--g-color-base-generic-accent:var(--g-color-private-white-200);--g-color-base-generic-accent-disabled:var(--g-color-private-white-150);--g-color-base-generic-ultralight:var(--g-color-private-white-50);--g-color-base-simple-hover:var(--g-color-private-white-250);--g-color-base-simple-hover-solid:var(--g-color-private-white-250-solid);--g-color-base-brand:var(--g-color-private-yellow-550-solid);--g-color-base-brand-hover:var(--g-color-private-yellow-700-solid);--g-color-base-selection:var(--g-color-private-yellow-250);--g-color-base-selection-hover:var(--g-color-private-yellow-400);--g-color-base-info-light:var(--g-color-private-blue-250);--g-color-base-info-light-hover:var(--g-color-private-blue-400);--g-color-base-info-medium:var(--g-color-private-blue-450);--g-color-base-info-medium-hover:var(--g-color-private-blue-600-solid);--g-color-base-info-heavy:var(--g-color-private-blue-700-solid);--g-color-base-info-heavy-hover:var(--g-color-private-blue-850-solid);--g-color-base-positive-light:var(--g-color-private-green-250);--g-color-base-positive-light-hover:var(--g-color-private-green-400);--g-color-base-positive-medium:var(--g-color-private-green-450);--g-color-base-positive-medium-hover:var(--g-color-private-green-600-solid);--g-color-base-positive-heavy:var(--g-color-private-green-700-solid);--g-color-base-positive-heavy-hover:var(--g-color-private-green-850-solid);--g-color-base-warning-light:var(--g-color-private-yellow-250);--g-color-base-warning-light-hover:var(--g-color-private-yellow-400);--g-color-base-warning-medium:var(--g-color-private-yellow-450);--g-color-base-warning-medium-hover:var(--g-color-private-yellow-600-solid);--g-color-base-warning-heavy:var(--g-color-private-yellow-700-solid);--g-color-base-warning-heavy-hover:var(--g-color-private-yellow-850-solid);--g-color-base-danger-light:var(--g-color-private-red-250);--g-color-base-danger-light-hover:var(--g-color-private-red-400);--g-color-base-danger-medium:var(--g-color-private-red-450);--g-color-base-danger-medium-hover:var(--g-color-private-red-600-solid);--g-color-base-danger-heavy:var(--g-color-private-red-700-solid);--g-color-base-danger-heavy-hover:var(--g-color-private-red-850-solid);--g-color-base-utility-light:var(--g-color-private-purple-250);--g-color-base-utility-light-hover:var(--g-color-private-purple-400);--g-color-base-utility-medium:var(--g-color-private-purple-450);--g-color-base-utility-medium-hover:var(--g-color-private-purple-600-solid);--g-color-base-utility-heavy:var(--g-color-private-purple-700-solid);--g-color-base-utility-heavy-hover:var(--g-color-private-purple-850-solid);--g-color-base-neutral-light:var(--g-color-private-white-200);--g-color-base-neutral-light-hover:var(--g-color-private-white-350);--g-color-base-neutral-medium:var(--g-color-private-white-400);--g-color-base-neutral-medium-hover:var(--g-color-private-white-550);--g-color-base-neutral-heavy:var(--g-color-private-white-650);--g-color-base-neutral-heavy-hover:var(--g-color-private-white-750);--g-color-base-misc-light:var(--g-color-private-cool-grey-250);--g-color-base-misc-light-hover:var(--g-color-private-cool-grey-400);--g-color-base-misc-medium:var(--g-color-private-cool-grey-450);--g-color-base-misc-medium-hover:var(--g-color-private-cool-grey-600-solid);--g-color-base-misc-heavy:var(--g-color-private-cool-grey-700-solid);--g-color-base-misc-heavy-hover:var(--g-color-private-cool-grey-850-solid);--g-color-base-light:var(--g-color-private-white-850);--g-color-base-light-hover:var(--g-color-private-white-700);--g-color-base-light-simple-hover:var(--g-color-private-white-150);--g-color-base-light-disabled:var(--g-color-private-white-150);--g-color-base-light-accent-disabled:var(--g-color-private-white-300);--g-color-base-float:var(--g-color-private-white-100-solid);--g-color-base-float-hover:var(--g-color-private-white-200-solid);--g-color-base-float-medium:var(--g-color-private-white-200-solid);--g-color-base-float-heavy:var(--g-color-private-white-300-solid);--g-color-base-float-accent:var(--g-color-private-white-300-solid);--g-color-base-float-accent-hover:var(--g-color-private-white-400-solid);--g-color-base-float-announcement:var(--g-color-private-white-200-solid);--g-color-base-modal:var(--g-color-base-background);--g-color-line-generic:var(--g-color-private-white-150);--g-color-line-generic-hover:var(--g-color-private-white-250);--g-color-line-generic-active:var(--g-color-private-white-600);--g-color-line-generic-accent:var(--g-color-private-white-350);--g-color-line-generic-accent-hover:var(--g-color-private-white-800);--g-color-line-generic-solid:var(--g-color-private-white-150-solid);--g-color-line-brand:var(--g-color-private-yellow-600-solid);--g-color-line-focus:var(--g-color-private-cool-grey-550-solid);--g-color-line-light:var(--g-color-private-white-500);--g-color-line-info:var(--g-color-private-blue-550-solid);--g-color-line-positive:var(--g-color-private-green-550-solid);--g-color-line-warning:var(--g-color-private-yellow-550-solid);--g-color-line-danger:var(--g-color-private-red-550-solid);--g-color-line-utility:var(--g-color-private-purple-550-solid);--g-color-line-misc:var(--g-color-private-cool-grey-550-solid);--g-color-sfx-veil:var(--g-color-private-black-700);--g-color-sfx-shadow:var(--g-color-private-black-200);--g-color-sfx-shadow-heavy:var(--g-color-private-black-400);--g-color-sfx-shadow-light:var(--g-color-private-black-200);--g-color-sfx-fade:var(--g-color-private-white-250);--g-color-scroll-track:var(--g-color-base-background);--g-color-scroll-handle:var(--g-color-private-white-150);--g-color-scroll-handle-hover:var(--g-color-private-white-250);--g-color-scroll-corner:var(--g-color-private-white-150);--g-color-infographics-axis:var(--g-color-private-white-150-solid);--g-color-infographics-tooltip-bg:var(--g-color-private-white-opaque-150)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar){scrollbar-color:var(--g-color-scroll-handle) var(--g-color-scroll-track);scrollbar-width:var(--g-scrollbar-width)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar{background:var(--g-color-scroll-track);height:var(--g-scrollbar-width);width:var(--g-scrollbar-width)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-track,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-track{background:var(--g-color-scroll-track)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-corner,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-corner{background:var(--g-color-scroll-corner)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-thumb,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-thumb{background:var(--g-color-scroll-handle)}.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar) ::-webkit-scrollbar-thumb:hover,.g-root:not(.g-root_mobile):not(.g-root_native-scrollbar)::-webkit-scrollbar-thumb:hover{background:var(--g-color-scroll-handle-hover)}@keyframes g-loading-animation{0%{background-position:-12px 0}to{background-position:0 0}}:root:has(body.g-root_theme_light),:root:has(body.g-root_theme_light-hc){color-scheme:light}:root:has(body.g-root_theme_dark),:root:has(body.g-root_theme_dark-hc){color-scheme:dark}@media(prefers-reduced-motion:reduce){*,:after,:before{animation-duration:.001ms!important;animation-iteration-count:1!important;scroll-behavior:auto!important;transition-duration:.001ms!important}}:root{--data-table-header-vertical-padding:5px;--data-table-cell-vertical-padding:5px;--data-table-cell-horizontal-padding:10px;--data-table-cell-border-padding:var(--data-table-cell-horizontal-padding);--data-table-cell-align:top;--data-table-head-align:top;--data-table-row-height:30px;--data-table-sort-icon-space:18px;--data-table-sort-icon-opacity-inactive:0.15;--data-table-sort-icon-color:inherit}.data-table{box-sizing:border-box;position:relative}.data-table__box{box-sizing:border-box;height:100%;width:100%}.data-table__box_sticky-head_moving{overflow:visible;position:relative;z-index:0}.data-table__box_sticky-head_moving .data-table__th{border-bottom:0;border-top:0;padding-bottom:0;padding-top:0}.data-table__box_sticky-head_moving .data-table__head-cell{display:block;height:0;overflow:hidden}.data-table__box_sticky-head_moving .data-table__row_header-data{visibility:hidden}.data-table__box_sticky-footer_fixed,.data-table__box_sticky-head_fixed{overflow:auto}.data-table__table{border-collapse:collapse;table-layout:fixed}.data-table__table_sticky{background:var(--data-table-color-base);width:100%}.data-table__row{height:var(--data-table-row-height)}.data-table__th{border:1px solid var(--data-table-border-color);box-sizing:border-box;cursor:default;font-weight:500;padding:var(--data-table-header-vertical-padding) var(--data-table-cell-horizontal-padding);position:relative;text-align:left;vertical-align:var(--data-table-head-align)}.data-table__th_sortable{cursor:pointer}.data-table__th_sortable .data-table__head-cell{padding-right:var(--data-table-sort-icon-space)}.data-table__th_sortable.data-table__th_align_right .data-table__head-cell{padding-left:var(--data-table-sort-icon-space);padding-right:0}.data-table__th_sortable.data-table__th_align_right .data-table__sort-icon{left:0;right:auto;transform:translateY(-50%) scaleX(-1)}.data-table__td{border:1px solid var(--data-table-border-color);box-sizing:border-box;overflow:hidden;padding:var(--data-table-cell-vertical-padding) var(--data-table-cell-horizontal-padding);text-overflow:ellipsis;vertical-align:var(--data-table-cell-align);white-space:nowrap}.data-table__td_index,.data-table__th_index{text-align:right}.data-table__td_align_left,.data-table__th_align_left{text-align:left}.data-table__td_align_center,.data-table__th_align_center{text-align:center}.data-table__td_align_right,.data-table__th_align_right{text-align:right}.data-table__td:first-child,.data-table__th:first-child{padding-left:var(--data-table-cell-border-padding)}.data-table__td:last-child,.data-table__th:last-child{padding-right:var(--data-table-cell-border-padding)}.data-table__index{text-align:right}.data-table__head-cell{box-sizing:border-box;display:inline-block;max-width:100%;overflow:hidden;position:relative;text-overflow:ellipsis;vertical-align:top;white-space:nowrap}.data-table__error{padding:20px;white-space:pre-wrap}.data-table__sort-icon{color:var(--data-table-sort-icon-color);display:inline-flex;position:absolute;right:0;top:50%;transform:translateY(-50%)}.data-table__sort-icon:after{content:attr(data-index);font-size:8px;left:100%;position:absolute;top:-5px}.data-table__sort-icon_shadow{opacity:var(--data-table-sort-icon-opacity-inactive)}.data-table__sort-icon_shadow:after{content:none}.data-table__icon{vertical-align:top}.data-table__no-data{background:var(--data-table-color-stripe)}.data-table__sticky_fixed{left:0;overflow:hidden;position:absolute;right:0;z-index:1}.data-table__sticky_fixed.data-table__sticky_head{top:0}.data-table__sticky_fixed.data-table__sticky_footer{bottom:0}.data-table__sticky_moving{margin-bottom:-1px;position:sticky;z-index:1}.data-table_striped-rows .data-table__row_odd{background:var(--data-table-color-stripe)}.data-table_highlight-rows .data-table__row:hover{background:var(--data-table-color-hover-area)}.data-table_header_multiline .data-table__head-cell{white-space:normal}.data-table_header_pre .data-table__head-cell{white-space:pre}.data-table__foot{background:var(--data-table-color-footer-area)}.data-table__foot_has-sticky-footer_moving{visibility:hidden}.data-table_theme_yandex-cloud{--data-table-color-base:var(--g-color-base-background,var(--yc-color-base-background));--data-table-color-stripe:var( --g-color-base-generic-ultralight,var(--yc-color-base-generic-ultralight) );--data-table-border-color:var( --g-color-base-generic-hover,var(--yc-color-base-generic-hover) );--data-table-color-hover-area:var( --g-color-base-simple-hover,var(--yc-color-base-simple-hover) );--data-table-color-footer-area:var(--data-table-color-base)}.data-table_theme_legacy{--data-table-color-base:#fff;--data-table-color-stripe:#00000008;--data-table-border-color:#ddd;--data-table-color-hover-area:#ffeba0;--data-table-color-footer-area:var(--data-table-color-base)}.data-table__resize-handler{background-color:var(--g-color-base-generic);cursor:col-resize;height:100%;position:absolute;right:0;top:0;visibility:hidden;width:6px}.data-table__resize-handler_resizing,.data-table__th:hover>.data-table__resize-handler{visibility:visible}.ydb-error-boundary{align-items:flex-start;display:flex;flex-direction:row;font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height);padding:20px}.ydb-error-boundary__illustration{height:230px;margin-right:20px;width:230px}.ydb-error-boundary__error-title{font-size:var(--g-text-subheader-3-font-size);line-height:var(--g-text-subheader-3-line-height);margin-top:44px}.ydb-error-boundary__error-description{margin-top:12px}.ydb-error-boundary__show-details{margin-top:8px}.ydb-error-boundary__error-details{background-color:var(--g-color-base-generic-ultralight);border:1px solid var(--g-color-line-generic);padding:13px 18px;white-space:pre-wrap}.ydb-error-boundary__actions{display:flex;flex-direction:row;gap:10px;margin-top:20px}.g-icon{line-height:0;vertical-align:top}.g-arrow-toggle{display:inline-block;transition:transform .1s ease-out;vertical-align:middle}.g-arrow-toggle_direction_bottom{transform:matrix(1,0,0,1,0,0)}.g-arrow-toggle_direction_left{transform:matrix(0,1,-1,0,0,0)}.g-arrow-toggle_direction_top{transform:matrix(-1,0,0,-1,0,0)}.g-arrow-toggle_direction_right{transform:matrix(0,-1,1,0,0,0)}.g-disclosure_size_m .g-disclosure__trigger{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-disclosure_size_l .g-disclosure__trigger{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-disclosure_size_xl .g-disclosure__trigger{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-disclosure__trigger{align-items:center;background:none;border:none;border-radius:var(--g-focus-border-radius);color:inherit;cursor:pointer;display:flex;flex-flow:row nowrap;flex-shrink:0;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);font-weight:inherit;gap:8px;line-height:inherit;outline:none;padding:0}.g-disclosure__trigger:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-disclosure__trigger_arrow_end{flex-direction:row-reverse}.g-disclosure__trigger_disabled{color:var(--g-color-text-secondary);cursor:auto}.g-disclosure__content{display:none}.g-disclosure__content_visible{display:block}.g-disclosure__content.g-disclosure_exit_active{animation-duration:.1s;animation-name:g-disclosure-collapsed;display:block;opacity:0}.g-disclosure__content.g-disclosure_enter_active{animation-duration:.2s;animation-name:g-disclosure-expanded}@keyframes g-disclosure-expanded{0%{opacity:.4}to{opacity:1}}@keyframes g-disclosure-collapsed{0%{opacity:1}to{opacity:0}}.g-button{--_--text-color:var(--g-color-text-primary);--_--text-color-hover:var(--_--text-color);--_--background-color:#0000;--_--background-color-hover:var(--g-color-base-simple-hover);--_--border-width:0;--_--border-color:currentColor;--_--focus-outline-color:var(--g-color-line-focus);--_--focus-outline-offset:0;--_--font-size:var(--g-text-body-1-font-size);-webkit-tap-highlight-color:rgba(0,0,0,0);background:none;background:#0000;border:none;box-sizing:border-box;color:inherit;color:var(--g-button-text-color,var(--_--text-color));cursor:pointer;display:inline-flex;font-family:var(--g-text-body-font-family);font-size:inherit;font-size:var(--g-button-font-size,var(--_--font-size));font-weight:var(--g-text-body-font-weight);gap:var(--g-button-icon-offset,var(--_--icon-offset));height:var(--g-button-height,var(--_--height));justify-content:center;line-height:var(--g-button-height,var(--_--height));outline:none;overflow:visible;padding:0;padding:0 var(--g-button-padding,var(--_--padding));position:relative;text-align:center;text-decoration:none;touch-action:manipulation;transform:scale(1);transition:transform .1s ease-out,color .15s linear;-webkit-user-select:none;user-select:none;white-space:nowrap}.g-button:before{background-color:var(--g-button-background-color,var(--_--background-color));border:var(--g-button-border-width,var(--_--border-width)) var(--g-button-border-style,solid) var(--g-button-border-color,var(--_--border-color));content:"";inset:0;position:absolute;transition:background-color .15s linear;z-index:-1}.g-button:hover{color:var(--g-button-text-color-hover,var(--_--text-color-hover))}.g-button:hover:before{background-color:var(--g-button-background-color-hover,var(--_--background-color-hover))}.g-button:focus-visible:before{outline:var(--g-button-focus-outline-color,var(--_--focus-outline-color)) var(--g-button-focus-outline-style,solid) var(--g-button-focus-outline-width,2px);outline-offset:var(--g-button-focus-outline-offset,var(--_--focus-outline-offset))}.g-button:after{content:"";inset:0;position:absolute;transform:scale(1);transition:none;z-index:-1}.g-button:active{transform:scale(.96);transition:none}.g-button:active:after{transform:scale(1.042)}.g-button_size_xs{--_--height:20px;--_--border-radius:var(--g-border-radius-xs);--_--padding:6px;--_--icon-size:12px;--_--icon-offset:4px}.g-button_size_s{--_--height:24px;--_--border-radius:var(--g-border-radius-s);--_--padding:8px;--_--icon-size:16px;--_--icon-offset:4px}.g-button_size_m{--_--height:28px;--_--border-radius:var(--g-border-radius-m);--_--padding:12px;--_--icon-size:16px;--_--icon-offset:8px}.g-button_size_l{--_--height:36px;--_--border-radius:var(--g-border-radius-l);--_--padding:16px;--_--icon-size:16px;--_--icon-offset:8px}.g-button_size_xl{--_--height:44px;--_--border-radius:var(--g-border-radius-xl);--_--padding:24px;--_--icon-size:20px;--_--icon-offset:12px;--_--font-size:var(--g-text-body-2-font-size)}.g-button_view_normal{--_--background-color:var(--g-color-base-generic);--_--background-color-hover:var(--g-color-base-generic-hover)}.g-button_view_action{--_--text-color:var(--g-color-text-brand-contrast);--_--background-color:var(--g-color-base-brand);--_--background-color-hover:var(--g-color-base-brand-hover);--_--focus-outline-color:var(--g-color-base-brand);--_--focus-outline-offset:1px}.g-button_view_outlined{--_--border-width:1px;--_--border-color:var(--g-color-line-generic)}.g-button_view_outlined-info{--_--text-color:var(--g-color-text-info);--_--border-width:1px;--_--border-color:var(--g-color-line-info)}.g-button_view_outlined-success{--_--text-color:var(--g-color-text-positive);--_--border-width:1px;--_--border-color:var(--g-color-line-positive)}.g-button_view_outlined-warning{--_--text-color:var(--g-color-text-warning);--_--border-width:1px;--_--border-color:var(--g-color-line-warning)}.g-button_view_outlined-danger{--_--text-color:var(--g-color-text-danger);--_--border-width:1px;--_--border-color:var(--g-color-line-danger)}.g-button_view_outlined-utility{--_--text-color:var(--g-color-text-utility);--_--border-width:1px;--_--border-color:var(--g-color-line-utility)}.g-button_view_outlined-action{--_--text-color:var(--g-color-text-brand);--_--border-width:1px;--_--border-color:var(--g-color-line-brand)}.g-button_view_raised{--_--background-color-hover:var(--g-color-base-float-hover);background:var(--g-color-base-float)}.g-button_view_raised:before{box-shadow:0 3px 5px var(--g-color-sfx-shadow)}.g-button_view_raised:active:before{box-shadow:0 1px 2px var(--g-color-sfx-shadow)}.g-button_view_flat-secondary{--_--text-color:var(--g-color-text-secondary);--_--text-color-hover:var(--g-color-text-primary)}.g-button_view_flat-info{--_--text-color:var(--g-color-text-info)}.g-button_view_flat-success{--_--text-color:var(--g-color-text-positive)}.g-button_view_flat-warning{--_--text-color:var(--g-color-text-warning)}.g-button_view_flat-danger{--_--text-color:var(--g-color-text-danger)}.g-button_view_flat-utility{--_--text-color:var(--g-color-text-utility)}.g-button_view_flat-action{--_--text-color:var(--g-color-text-brand)}.g-button_view_normal-contrast{--_--text-color:var(--g-color-text-dark-primary);--_--background-color:var(--g-color-base-light);--_--background-color-hover:var(--g-color-base-light-hover);--_--focus-outline-color:var(--g-color-line-light)}.g-button_view_normal-contrast.g-button_loading{--_--background-color-hover:var(--g-color-base-simple-hover)}.g-button_view_outlined-contrast{--_--text-color:var(--g-color-text-light-primary);--_--background-color-hover:var(--g-color-base-light-simple-hover);--_--border-width:1px;--_--border-color:var(--g-color-line-light);--_--focus-outline-color:var(--g-color-line-light)}.g-button_view_flat-contrast{--_--text-color:var(--g-color-text-light-primary);--_--background-color-hover:var(--g-color-base-light-simple-hover);--_--focus-outline-color:var(--g-color-line-light)}.g-button.g-button_pin_round-round.g-button{border-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-brick.g-button{border-radius:0}.g-button.g-button_pin_clear-clear.g-button{border-inline:0;border-radius:0}.g-button.g-button_pin_circle-circle.g-button{border-radius:100px}.g-button.g-button_pin_round-brick.g-button{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-round.g-button{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_round-clear.g-button{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_clear-round.g-button{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_brick-clear.g-button{border-inline-end:0;border-radius:0}.g-button.g-button_pin_clear-brick.g-button{border-inline-start:0;border-radius:0}.g-button.g-button_pin_circle-brick.g-button{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_brick-circle.g-button{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_circle-clear.g-button{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_clear-circle.g-button{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_round-round:before{border-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-brick:before{border-radius:0}.g-button.g-button_pin_clear-clear:before{border-inline:0;border-radius:0}.g-button.g-button_pin_circle-circle:before{border-radius:100px}.g-button.g-button_pin_round-brick:before{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-round:before{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_round-clear:before{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_clear-round:before{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_brick-clear:before{border-inline-end:0;border-radius:0}.g-button.g-button_pin_clear-brick:before{border-inline-start:0;border-radius:0}.g-button.g-button_pin_circle-brick:before{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_brick-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_circle-clear:before{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_clear-circle:before{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_round-round:after{border-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-brick:after{border-radius:0}.g-button.g-button_pin_clear-clear:after{border-inline:0;border-radius:0}.g-button.g-button_pin_circle-circle:after{border-radius:100px}.g-button.g-button_pin_round-brick:after{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_brick-round:after{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_round-clear:after{border-end-end-radius:0;border-end-start-radius:var(--g-button-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-button-border-radius,var(--_--border-radius))}.g-button.g-button_pin_clear-round:after{border-end-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-button-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-button.g-button_pin_brick-clear:after{border-inline-end:0;border-radius:0}.g-button.g-button_pin_clear-brick:after{border-inline-start:0;border-radius:0}.g-button.g-button_pin_circle-brick:after{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_brick-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button.g-button_pin_circle-clear:after{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-button.g-button_pin_clear-circle:after{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-button__text{display:inline-block;white-space:nowrap}.g-button__icon{display:inline-block;height:var(--g-button-height,var(--_--height));margin:0 calc((var(--g-button-height, var(--_--height)) - var(--g-button-icon-size, var(--_--icon-size)))/2*-1);position:relative;width:var(--g-button-height,var(--_--height))}.g-button__icon:after{content:" ";visibility:hidden}.g-button__icon-inner{align-items:center;display:flex;inset:0;justify-content:center;position:absolute}.g-button__icon_side_start{order:-1}.g-button__icon_side_end{order:1}.g-button__icon:only-child{margin:0}.g-button:has(.g-button__icon:only-child){--_--padding:0}.g-button:has(.g-button__icon:only-child):not(.g-button_width_max){width:var(--g-button-height,var(--_--height))}.g-button_selected:not(.g-button_view_outlined-contrast){--_--border-width:0}.g-button_selected:not(.g-button_view_normal-contrast,.g-button_view_flat-contrast,.g-button_view_outlined-contrast){--_--text-color:var(--g-color-text-brand-heavy);--_--background-color:var(--g-color-base-selection);--_--background-color-hover:var(--g-color-base-selection-hover)}.g-button_selected.g-button_view_flat-info,.g-button_selected.g-button_view_outlined-info{--_--text-color:var(--g-color-text-info-heavy);--_--background-color:var(--g-color-base-info-light);--_--background-color-hover:var(--g-color-base-info-light-hover)}.g-button_selected.g-button_view_flat-success,.g-button_selected.g-button_view_outlined-success{--_--text-color:var(--g-color-text-positive-heavy);--_--background-color:var(--g-color-base-positive-light);--_--background-color-hover:var(--g-color-base-positive-light-hover)}.g-button_selected.g-button_view_flat-warning,.g-button_selected.g-button_view_outlined-warning{--_--text-color:var(--g-color-text-warning-heavy);--_--background-color:var(--g-color-base-warning-light);--_--background-color-hover:var(--g-color-base-warning-light-hover)}.g-button_selected.g-button_view_flat-danger,.g-button_selected.g-button_view_outlined-danger{--_--text-color:var(--g-color-text-danger-heavy);--_--background-color:var(--g-color-base-danger-light);--_--background-color-hover:var(--g-color-base-danger-light-hover)}.g-button_selected.g-button_view_flat-utility,.g-button_selected.g-button_view_outlined-utility{--_--text-color:var(--g-color-text-utility-heavy);--_--background-color:var(--g-color-base-utility-light);--_--background-color-hover:var(--g-color-base-utility-light-hover)}.g-button_disabled{cursor:default;pointer-events:none}.g-button_disabled:not(.g-button_loading){--_--text-color:var(--g-color-text-hint);--_--background-color:var(--g-color-base-generic-accent-disabled);--_--background-color-hover:var(--g-color-base-generic-accent-disabled);--_--border-width:0}.g-button_disabled:not(.g-button_loading):is(.g-button_view_normal-contrast,.g-button_view_outlined-contrast){--_--text-color:var(--g-color-text-light-secondary);--_--background-color:var(--g-color-base-light-disabled);--_--background-color-hover:var(--g-color-base-light-disabled)}.g-button_disabled:not(.g-button_loading):is(.g-button_view_flat,.g-button_view_flat-secondary,.g-button_view_flat-info,.g-button_view_flat-success,.g-button_view_flat-warning,.g-button_view_flat-danger,.g-button_view_flat-utility,.g-button_view_flat-action,.g-button_view_flat-contrast){--_--text-color:var(--g-color-text-hint);--_--background-color:#0000;--_--background-color-hover:#0000}.g-button_disabled:not(.g-button_loading).g-button_view_flat-contrast{--_--text-color:var(--g-color-text-light-hint)}.g-button_disabled:active{transform:scale(1)}.g-button_loading:before{animation:g-loading-animation .5s linear infinite;background-clip:padding-box;background-image:repeating-linear-gradient(-45deg,var(--g-button-background-color,var(--_--background-color)),var(--g-button-background-color,var(--_--background-color)) 4px,var(--g-button-background-color-hover,var(--_--background-color-hover)) 4px,var(--g-button-background-color-hover,var(--_--background-color-hover)) 8px);background-size:150%}.g-button_width_auto{max-width:100%}.g-button_width_max{width:100%}.g-button_width_auto .g-button__text,.g-button_width_max .g-button__text{display:block;overflow:hidden;text-overflow:ellipsis}.g-switch{position:relative}.g-switch__control{cursor:pointer;opacity:0}.g-switch__indicator{display:inline-block;position:relative}.g-switch__indicator:before{background-color:var(--g-color-base-generic-medium);content:"";inset:0;position:absolute;transition:background .1s linear}.g-switch__indicator:after{content:" ";visibility:hidden}.g-switch__slider{background-color:var(--g-color-base-background);border-radius:50%;content:"";position:absolute;transition:transform .15s ease-out}.g-switch__outline{background:none;height:100%;inset-block-start:0;inset-inline-start:0;pointer-events:none;position:absolute;width:100%}.g-switch__control:focus-visible+.g-switch__outline{outline:2px solid var(--g-color-line-focus)}.g-switch_size_m .g-switch__indicator,.g-switch_size_m .g-switch__indicator:before,.g-switch_size_m .g-switch__outline{border-radius:10px;height:20px;width:36px}.g-switch_size_m .g-switch__slider{height:16px;inset-block-start:2px;inset-inline-start:2px;width:16px}.g-switch_size_m .g-switch__text{margin-block-start:3px}.g-switch_size_l .g-switch__indicator,.g-switch_size_l .g-switch__indicator:before,.g-switch_size_l .g-switch__outline{border-radius:12px;height:24px;width:42px}.g-switch_size_l .g-switch__slider{height:18px;inset-block-start:3px;inset-inline-start:3px;width:18px}.g-switch_size_l .g-switch__text{margin-block-start:4px}.g-switch:hover .g-switch__indicator:before{background-color:var(--g-color-base-generic-medium-hover)}.g-switch_checked .g-switch__slider{--_--translate-x:calc(100%*var(--g-flow-direction));transform:translateX(var(--_--translate-x))}.g-switch_checked .g-switch__indicator:before,.g-switch_checked:hover .g-switch__indicator:before{background-color:var(--g-color-base-brand)}.g-switch_disabled .g-switch__indicator:before{background-color:var(--g-color-base-generic-accent-disabled)}.g-switch_disabled.g-switch_checked .g-switch__indicator:before{background-color:var(--g-color-base-brand);opacity:.5}.g-control-label{-webkit-tap-highlight-color:rgba(0,0,0,0);color:var(--g-color-text-primary);cursor:pointer;display:inline-flex;font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight);touch-action:manipulation;-webkit-user-select:none;user-select:none}.g-control-label_disabled{cursor:default;pointer-events:none}.g-control-label_size_m{font-size:var(--g-text-body-1-font-size);line-height:15px}.g-control-label_size_l{font-size:var(--g-text-body-2-font-size);line-height:18px}.g-control-label__indicator{flex-shrink:0}.g-control-label__text{flex-grow:1;white-space:normal}.g-control-label_disabled .g-control-label__text{opacity:.6}.g-control-label_size_m .g-control-label__text{margin-inline-start:5px}.g-control-label_size_l .g-control-label__text{margin-inline-start:7px}.g-radio-button{--_--border-radius-inner:calc(var(--_--border-radius) - 3px);background-color:var(--g-color-base-generic);border-radius:var(--_--border-radius);box-sizing:border-box;display:inline-flex;flex-direction:row;font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight);position:relative}.g-radio-button__plate{inset-block:0;position:absolute;transition:left .2s,width .2s}.g-radio-button__plate[hidden]{display:none}.g-radio-button__option{border-radius:var(--_--border-radius-inner);cursor:pointer;flex:1 1 auto;font-size:var(--g-text-body-1-font-size);text-align:center;transform:scale(1);transition:color .15s linear;-webkit-user-select:none;user-select:none}.g-radio-button__option-outline{border-radius:var(--_--border-radius-inner);content:"";inset:3px;position:absolute;z-index:-1}.g-radio-button__option-control{border:none;cursor:inherit;height:100%;inset-block-start:0;inset-inline-start:0;margin:0;opacity:0;outline:none;padding:0;position:absolute;width:100%}.g-radio-button__option-control:focus-visible+.g-radio-button__option-outline{outline:2px solid var(--g-color-line-focus)}.g-radio-button__option-text{color:var(--g-color-text-complementary);display:inline-block;white-space:nowrap}.g-radio-button__option-text_icon{align-items:center;display:flex;height:100%}.g-radio-button__option:hover .g-radio-button__option-text,.g-radio-button__option_checked .g-radio-button__option-text{color:var(--g-color-text-primary)}.g-radio-button__option_checked{cursor:default}.g-radio-button__option_disabled{cursor:default;pointer-events:none}.g-radio-button__option_disabled .g-radio-button__option-text{color:var(--g-color-text-hint)}.g-radio-button__option:before,.g-radio-button__plate:before{border-radius:var(--_--border-radius-inner);inset:3px;position:absolute}.g-radio-button__option:before{z-index:-1}.g-radio-button__plate:before,.g-radio-button__plate[hidden]~.g-radio-button__option_checked:before{background-color:var(--g-color-base-background);content:""}.g-radio-button_size_s{--_--border-radius:var(--g-border-radius-s)}.g-radio-button_size_s .g-radio-button__option{height:24px;line-height:24px}.g-radio-button_size_s .g-radio-button__option-text{margin:0 10px}.g-radio-button_size_m{--_--border-radius:var(--g-border-radius-m)}.g-radio-button_size_m .g-radio-button__option{height:28px;line-height:28px}.g-radio-button_size_m .g-radio-button__option-text{margin:0 13px}.g-radio-button_size_l{--_--border-radius:var(--g-border-radius-l)}.g-radio-button_size_l .g-radio-button__option{height:36px;line-height:36px}.g-radio-button_size_l .g-radio-button__option-text{margin:0 18px}.g-radio-button_size_xl{--_--border-radius:var(--g-border-radius-xl)}.g-radio-button_size_xl .g-radio-button__option{font-size:var(--g-text-body-2-font-size);height:44px;line-height:44px}.g-radio-button_size_xl .g-radio-button__option-text{margin:0 25px}.g-radio-button_width_auto{max-width:100%}.g-radio-button_width_max{width:100%}.g-radio-button_width_auto .g-radio-button__option,.g-radio-button_width_max .g-radio-button__option{overflow:hidden}.g-radio-button_width_auto .g-radio-button__option-text,.g-radio-button_width_max .g-radio-button__option-text{display:block;overflow:hidden;text-overflow:ellipsis}.g-color-text_color_primary{color:var(--g-color-text-primary)}.g-color-text_color_complementary{color:var(--g-color-text-complementary)}.g-color-text_color_secondary{color:var(--g-color-text-secondary)}.g-color-text_color_hint{color:var(--g-color-text-hint)}.g-color-text_color_info{color:var(--g-color-text-info)}.g-color-text_color_info-heavy{color:var(--g-color-text-info-heavy)}.g-color-text_color_positive{color:var(--g-color-text-positive)}.g-color-text_color_positive-heavy{color:var(--g-color-text-positive-heavy)}.g-color-text_color_warning{color:var(--g-color-text-warning)}.g-color-text_color_warning-heavy{color:var(--g-color-text-warning-heavy)}.g-color-text_color_danger{color:var(--g-color-text-danger)}.g-color-text_color_danger-heavy{color:var(--g-color-text-danger-heavy)}.g-color-text_color_utility{color:var(--g-color-text-utility)}.g-color-text_color_utility-heavy{color:var(--g-color-text-utility-heavy)}.g-color-text_color_misc{color:var(--g-color-text-misc)}.g-color-text_color_misc-heavy{color:var(--g-color-text-misc-heavy)}.g-color-text_color_brand{color:var(--g-color-text-brand)}.g-color-text_color_link{color:var(--g-color-text-link)}.g-color-text_color_link-hover{color:var(--g-color-text-link-hover)}.g-color-text_color_link-visited{color:var(--g-color-text-link-visited)}.g-color-text_color_link-visited-hover{color:var(--g-color-text-link-visited-hover)}.g-color-text_color_dark-primary{color:var(--g-color-text-dark-primary)}.g-color-text_color_dark-complementary{color:var(--g-color-text-dark-complementary)}.g-color-text_color_dark-secondary{color:var(--g-color-text-dark-secondary)}.g-color-text_color_light-primary{color:var(--g-color-text-light-primary)}.g-color-text_color_light-complementary{color:var(--g-color-text-light-complementary)}.g-color-text_color_light-secondary{color:var(--g-color-text-light-secondary)}.g-color-text_color_light-hint{color:var(--g-color-text-light-hint)}.g-color-text_color_inverted-primary{color:var(--g-color-text-inverted-primary)}.g-color-text_color_inverted-complementary{color:var(--g-color-text-inverted-complementary)}.g-color-text_color_inverted-secondary{color:var(--g-color-text-inverted-secondary)}.g-color-text_color_inverted-hint{color:var(--g-color-text-inverted-hint)}.g-text_variant_display-1{font-size:var(--g-text-display-1-font-size);line-height:var(--g-text-display-1-line-height)}.g-text_variant_display-1,.g-text_variant_display-2{font-family:var(--g-text-display-font-family);font-weight:var(--g-text-display-font-weight)}.g-text_variant_display-2{font-size:var(--g-text-display-2-font-size);line-height:var(--g-text-display-2-line-height)}.g-text_variant_display-3{font-size:var(--g-text-display-3-font-size);line-height:var(--g-text-display-3-line-height)}.g-text_variant_display-3,.g-text_variant_display-4{font-family:var(--g-text-display-font-family);font-weight:var(--g-text-display-font-weight)}.g-text_variant_display-4{font-size:var(--g-text-display-4-font-size);line-height:var(--g-text-display-4-line-height)}.g-text_variant_code-1{font-size:var(--g-text-code-1-font-size);line-height:var(--g-text-code-1-line-height)}.g-text_variant_code-1,.g-text_variant_code-2{font-family:var(--g-text-code-font-family);font-weight:var(--g-text-code-font-weight)}.g-text_variant_code-2{font-size:var(--g-text-code-2-font-size);line-height:var(--g-text-code-2-line-height)}.g-text_variant_code-3{font-size:var(--g-text-code-3-font-size);line-height:var(--g-text-code-3-line-height)}.g-text_variant_code-3,.g-text_variant_code-inline-1{font-family:var(--g-text-code-font-family);font-weight:var(--g-text-code-font-weight)}.g-text_variant_code-inline-1{font-size:var(--g-text-code-inline-1-font-size);line-height:var(--g-text-code-inline-1-line-height)}.g-text_variant_code-inline-2{font-size:var(--g-text-code-inline-2-font-size);line-height:var(--g-text-code-inline-2-line-height)}.g-text_variant_code-inline-2,.g-text_variant_code-inline-3{font-family:var(--g-text-code-font-family);font-weight:var(--g-text-code-font-weight)}.g-text_variant_code-inline-3{font-size:var(--g-text-code-inline-3-font-size);line-height:var(--g-text-code-inline-3-line-height)}.g-text_variant_body-1{font-size:var(--g-text-body-1-font-size);line-height:var(--g-text-body-1-line-height)}.g-text_variant_body-1,.g-text_variant_body-2{font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight)}.g-text_variant_body-2{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.g-text_variant_body-3{font-size:var(--g-text-body-3-font-size);line-height:var(--g-text-body-3-line-height)}.g-text_variant_body-3,.g-text_variant_body-short{font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight)}.g-text_variant_body-short{font-size:var(--g-text-body-short-font-size);line-height:var(--g-text-body-short-line-height)}.g-text_variant_caption-1{font-size:var(--g-text-caption-1-font-size);line-height:var(--g-text-caption-1-line-height)}.g-text_variant_caption-1,.g-text_variant_caption-2{font-family:var(--g-text-caption-font-family);font-weight:var(--g-text-caption-font-weight)}.g-text_variant_caption-2{font-size:var(--g-text-caption-2-font-size);line-height:var(--g-text-caption-2-line-height)}.g-text_variant_header-1{font-size:var(--g-text-header-1-font-size);line-height:var(--g-text-header-1-line-height)}.g-text_variant_header-1,.g-text_variant_header-2{font-family:var(--g-text-header-font-family);font-weight:var(--g-text-header-font-weight)}.g-text_variant_header-2{font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.g-text_variant_subheader-1{font-size:var(--g-text-subheader-1-font-size);line-height:var(--g-text-subheader-1-line-height)}.g-text_variant_subheader-1,.g-text_variant_subheader-2{font-family:var(--g-text-subheader-font-family);font-weight:var(--g-text-subheader-font-weight)}.g-text_variant_subheader-2{font-size:var(--g-text-subheader-2-font-size);line-height:var(--g-text-subheader-2-line-height)}.g-text_variant_subheader-3{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-text_ellipsis{display:inline-block;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-text_ellipsis-lines{-webkit-box-orient:vertical;-webkit-line-clamp:2;align-self:center;display:-webkit-box;overflow:hidden;white-space:normal}.g-text_ws_nowrap{white-space:nowrap}.g-text_ws_break-spaces{white-space:break-spaces}.g-text_wb_break-all{word-break:break-all}.g-text_wb_break-word{word-break:break-word}.g-label{--_--bg-color:none;--_--bg-color-hover:none;--_--text-color:none;align-items:center;background-color:var(--_--bg-color);border-radius:var(--_--border-radius);box-sizing:border-box;color:var(--_--text-color);display:inline-flex;height:var(--_--height);isolation:isolate;position:relative;transition-duration:.15s;transition-property:opacity,color,background-color;transition-timing-function:ease-in-out}.g-label__text{align-items:baseline;display:flex;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height);line-height:var(--_--height);margin:0 var(--_--margin-inline);overflow:hidden;text-align:center;white-space:nowrap;width:100%}.g-label__content,.g-label__key{overflow:hidden;text-overflow:ellipsis}.g-label__value{display:flex;opacity:.7;overflow:hidden}.g-label__separator{margin:0 4px}.g-label__main-button{background:none;border:none;border-radius:inherit;color:inherit;cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;z-index:1}.g-label__main-button:empty{inset:0;position:absolute}.g-label__addon{align-items:center;border-radius:var(--_--border-radius);display:flex;height:var(--_--height);justify-content:center;width:var(--_--height)}.g-label__addon_side_end,.g-label__addon_side_start{inset-block-start:0;position:absolute}.g-label__addon_side_start{border-end-end-radius:0;border-start-end-radius:0;inset-inline-start:2px}.g-label__addon_side_end{border-end-start-radius:0;border-start-start-radius:0;inset-inline-end:0}.g-label__addon_type_button{background:none;background-color:initial;border:none;color:inherit;color:var(--_--text-color);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0;transition:color .15s ease-in-out,background-color .15s ease-in-out,transform .1s ease-out;z-index:2}.g-label__addon_type_button:active{transform:scale(.96)}.g-label_size_xs{--_--height:20px;--_--border-radius:var(--g-border-radius-xs);--_--margin-inline:8px;--_--margin-addon-start:24px;--_--margin-addon-end:22px}.g-label_size_s{--_--height:24px;--_--border-radius:var(--g-border-radius-s);--_--margin-inline:10px;--_--margin-addon-start:28px;--_--margin-addon-end:26px}.g-label_size_m{--_--height:28px;--_--border-radius:var(--g-border-radius-m);--_--margin-inline:12px;--_--margin-addon-start:32px;--_--margin-addon-end:32px}.g-label_disabled{opacity:.7;pointer-events:none}.g-label_interactive{cursor:pointer}.g-label_theme_normal{--_--bg-color:var(--g-color-base-misc-light);--_--bg-color-hover:var(--g-color-base-misc-light-hover);--_--text-color:var(--g-color-text-misc-heavy)}.g-label_theme_success{--_--bg-color:var(--g-color-base-positive-light);--_--bg-color-hover:var(--g-color-base-positive-light-hover);--_--text-color:var(--g-color-text-positive-heavy)}.g-label_theme_info{--_--bg-color:var(--g-color-base-info-light);--_--bg-color-hover:var(--g-color-base-info-light-hover);--_--text-color:var(--g-color-text-info-heavy)}.g-label_theme_warning{--_--bg-color:var(--g-color-base-warning-light);--_--bg-color-hover:var(--g-color-base-warning-light-hover);--_--text-color:var(--g-color-text-warning-heavy)}.g-label_theme_danger{--_--bg-color:var(--g-color-base-danger-light);--_--bg-color-hover:var(--g-color-base-danger-light-hover);--_--text-color:var(--g-color-text-danger-heavy)}.g-label_theme_utility{--_--bg-color:var(--g-color-base-utility-light);--_--bg-color-hover:var(--g-color-base-utility-light-hover);--_--text-color:var(--g-color-text-utility-heavy)}.g-label_theme_unknown{--_--bg-color:var(--g-color-base-neutral-light);--_--bg-color-hover:var(--g-color-base-neutral-light-hover);--_--text-color:var(--g-color-text-complementary)}.g-label_theme_clear{--_--bg-color:#0000;--_--bg-color-hover:var(--g-color-base-simple-hover);--_--text-color:var(--g-color-text-complementary);box-shadow:inset 0 0 0 1px var(--g-color-line-generic)}.g-label:has(.g-label__addon_side_start) .g-label__text{margin-inline-start:var(--_--margin-addon-start)}.g-label:has(.g-label__addon_side_end) .g-label__text{margin-inline-end:var(--_--margin-addon-end)}.g-label__addon_type_button:hover,.g-label_interactive:hover:not(:has(.g-label__addon_type_button:hover)){background-color:var(--_--bg-color-hover)}.g-label__addon_type_button:focus-visible,.g-label__main-button:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-tabs{--_--vertical-item-padding:var(--g-tabs-vertical-item-padding,6px 20px);--_--vertical-item-height:var(--g-tabs-vertical-item-height,18px)}.g-tabs_size_m{--_--item-height:36px;--_--item-gap:24px;--_--item-border-width:2px}.g-tabs_size_m .g-tabs__item-counter,.g-tabs_size_m .g-tabs__item-title{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-tabs_size_l{--_--item-height:40px;--_--item-gap:28px;--_--item-border-width:2px}.g-tabs_size_l .g-tabs__item-counter,.g-tabs_size_l .g-tabs__item-title{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-tabs_size_xl{--_--item-height:44px;--_--item-gap:32px;--_--item-border-width:3px}.g-tabs_size_xl .g-tabs__item-counter,.g-tabs_size_xl .g-tabs__item-title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-tabs__item{cursor:pointer;outline:none;-webkit-user-select:none;user-select:none}.g-tabs__item-content{align-items:center;border-radius:var(--g-focus-border-radius);display:flex}.g-tabs__item_overflow .g-tabs__item-content{min-width:0}.g-tabs__item-icon{margin-inline-end:8px}.g-tabs__item-title{white-space:nowrap}.g-tabs__item_overflow .g-tabs__item-title{overflow:hidden;text-overflow:ellipsis}.g-tabs__item-counter,.g-tabs__item-label{margin-inline-start:8px}.g-tabs__item-icon>svg{display:block}.g-tabs_direction_horizontal{align-items:flex-end;box-shadow:inset 0 calc(var(--g-tabs-border-width, 1px)*-1) 0 0 var(--g-color-line-generic);display:flex;flex-wrap:wrap;overflow:hidden}.g-tabs_direction_horizontal .g-tabs__item{align-items:center;border-block-end:var(--g-tabs-item-border-width,var(--_--item-border-width)) solid #0000;box-sizing:border-box;display:flex;height:var(--g-tabs-item-height,var(--_--item-height));padding-block-start:var(--_--item-border-width)}.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-content{outline:2px solid var(--g-color-line-focus);outline-offset:-2px}.g-tabs_direction_horizontal .g-tabs__item-meta{display:none}.g-tabs_direction_horizontal .g-tabs__item-title{color:var(--g-color-text-secondary)}.g-tabs_direction_horizontal .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item-icon{color:var(--g-color-text-hint)}.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-title,.g-tabs_direction_horizontal .g-tabs__item:hover .g-tabs__item-title,.g-tabs_direction_horizontal .g-tabs__item_active .g-tabs__item-title{color:var(--g-color-text-primary)}.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item:focus-visible .g-tabs__item-icon,.g-tabs_direction_horizontal .g-tabs__item:hover .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item:hover .g-tabs__item-icon,.g-tabs_direction_horizontal .g-tabs__item_active .g-tabs__item-counter,.g-tabs_direction_horizontal .g-tabs__item_active .g-tabs__item-icon{color:var(--g-color-text-secondary)}.g-tabs_direction_horizontal .g-tabs__item_active,.g-tabs_direction_horizontal .g-tabs__item_active:focus-visible,.g-tabs_direction_horizontal .g-tabs__item_active:hover{border-color:var(--g-color-line-brand)}.g-tabs_direction_horizontal .g-tabs__item_disabled{pointer-events:none}.g-tabs_direction_horizontal .g-tabs__item_disabled .g-tabs__item-title{color:var(--g-color-text-hint)}.g-tabs_direction_horizontal>:not(:last-child){margin-inline-end:var(--g-tabs-item-gap,var(--_--item-gap))}.g-tabs_direction_vertical{display:flex;flex-direction:column}.g-tabs_direction_vertical .g-tabs__item{padding:var(--_--vertical-item-padding)}.g-tabs_direction_vertical .g-tabs__item-title{color:var(--g-color-text-primary);line-height:var(--_--vertical-item-height)}.g-tabs_direction_vertical .g-tabs__item-meta{color:var(--g-color-text-secondary);line-height:var(--_--vertical-item-height)}.g-tabs_direction_vertical .g-tabs__item-counter,.g-tabs_direction_vertical .g-tabs__item-icon{color:var(--g-color-text-secondary)}.g-tabs_direction_vertical .g-tabs__item:focus-visible,.g-tabs_direction_vertical .g-tabs__item:hover{background-color:var(--g-color-base-generic-hover)}.g-tabs_direction_vertical .g-tabs__item_active{background-color:var(--g-color-base-selection)}.g-tabs_direction_vertical .g-tabs__item_active:focus-visible,.g-tabs_direction_vertical .g-tabs__item_active:hover{background-color:var(--g-color-base-selection-hover)}.g-tabs_direction_vertical .g-tabs__item_disabled{pointer-events:none}.g-tabs_direction_vertical .g-tabs__item_disabled .g-tabs__item-title{color:var(--g-color-text-secondary)}.g-outer-additional-content{display:flex;justify-content:space-between;vertical-align:top}.g-outer-additional-content__error,.g-outer-additional-content__note{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height);margin-block-start:2px}.g-outer-additional-content__error{color:var(--g-color-text-danger)}.g-outer-additional-content__error:not(:last-child){margin-inline-end:var(--g-spacing-2)}.g-outer-additional-content__note{margin-inline-start:auto}.g-text-input{--_--text-color:var(--g-color-text-primary);--_--label-color:inherit;--_--placeholder-color:var(--g-color-text-hint);--_--background-color:#0000;--_--border-width:1px;--_--focus-outline-color:var(--g-text-input-focus-outline-color);display:inline-block;position:relative;width:100%}.g-text-input__content{background-color:var(--g-text-input-background-color,var(--_--background-color));border-color:var(--g-text-input-border-color,var(--_--border-color));border-style:solid;border-width:var(--g-text-input-border-width,var(--_--border-width));box-sizing:border-box;color:var(--g-text-input-text-color,var(--_--text-color));display:flex;overflow:hidden;width:100%}.g-text-input__content:hover{border-color:var(--g-text-input-border-color-hover,var(--_--border-color-hover))}.g-text-input__content:focus-within{border-color:var(--g-text-input-border-color-active,var(--_--border-color-active));outline:2px solid var(--g-text-input-focus-outline-color,var(--_--focus-outline-color));outline-offset:-1px}.g-text-input__control{background-color:initial;border:none;box-sizing:border-box;color:inherit;display:inline-block;flex-grow:1;font-family:var(--g-text-body-font-family);font-weight:var(--g-text-body-font-weight);height:var(--g-text-input-height);margin:0;padding:0;position:relative;vertical-align:top;width:100%}.g-text-input__control::placeholder{color:var(--g-text-input-placeholder-color,var(--_--placeholder-color));overflow:hidden;white-space:nowrap}.g-text-input__control:focus{outline:none}.g-text-input__control[type=number]{appearance:textfield}.g-text-input__label{box-sizing:border-box;color:var(--g-text-input-label-color,var(--_--label-color));overflow:hidden;position:absolute;text-overflow:ellipsis;white-space:nowrap;z-index:1}.g-text-input__clear{flex-shrink:0;margin:auto 0}.g-text-input__clear_size_m,.g-text-input__clear_size_s{margin-inline-end:1px}.g-text-input__clear_size_l,.g-text-input__clear_size_xl{margin-inline-end:2px}.g-text-input__error-icon{box-sizing:initial;color:var(--g-color-text-danger);padding-block:var(--_--error-icon-padding-block);padding-inline:var(--_--error-icon-padding-inline)}.g-text-input__additional-content{align-items:center;display:flex}.g-text-input_size_s{--_--error-icon-padding-block:5px;--_--error-icon-padding-inline:0 5px;--_--border-radius:var(--g-border-radius-s)}.g-text-input_size_s .g-text-input__control{--_--input-control-border-width:var( - --g-text-input-border-width,var(--g-text-area-border-width,1px) - );height:calc(24px - var(--_--input-control-border-width)*2);padding:3px 8px}.g-text-input_size_s .g-text-input__control,.g-text-input_size_s .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-text-input_size_s .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:3px;padding-inline:8px 4px}.g-text-input_size_s.g-text-input_has-start-content .g-text-input__label{padding-inline-start:2px}.g-text-input_size_s .g-text-input__additional-content{height:22px}.g-text-input_size_s .g-text-input__additional-content_placement_start{padding-inline-start:1px}.g-text-input_size_s .g-text-input__additional-content_placement_end{padding-inline-end:1px}.g-text-input_size_m{--_--error-icon-padding-block:5px;--_--error-icon-padding-inline:0 5px;--_--border-radius:var(--g-border-radius-m)}.g-text-input_size_m .g-text-input__control{--_--input-control-border-width:var( - --g-text-input-border-width,var(--g-text-area-border-width,1px) - );height:calc(28px - var(--_--input-control-border-width)*2);padding:5px 8px}.g-text-input_size_m .g-text-input__control,.g-text-input_size_m .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-text-input_size_m .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:5px;padding-inline:8px 4px}.g-text-input_size_m.g-text-input_has-start-content .g-text-input__label{padding-inline-start:2px}.g-text-input_size_m .g-text-input__additional-content{height:26px}.g-text-input_size_m .g-text-input__additional-content_placement_start{padding-inline-start:1px}.g-text-input_size_m .g-text-input__additional-content_placement_end{padding-inline-end:1px}.g-text-input_size_l{--_--error-icon-padding-block:9px;--_--error-icon-padding-inline:0 9px;--_--border-radius:var(--g-border-radius-l)}.g-text-input_size_l .g-text-input__control{--_--input-control-border-width:var( - --g-text-input-border-width,var(--g-text-area-border-width,1px) - );height:calc(36px - var(--_--input-control-border-width)*2);padding:9px 12px}.g-text-input_size_l .g-text-input__control,.g-text-input_size_l .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-short-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-short-line-height)}.g-text-input_size_l .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:9px;padding-inline:12px 4px}.g-text-input_size_l.g-text-input_has-start-content .g-text-input__label{padding-inline-start:3px}.g-text-input_size_l .g-text-input__additional-content{height:34px}.g-text-input_size_l .g-text-input__additional-content_placement_start{padding-inline-start:3px}.g-text-input_size_l .g-text-input__additional-content_placement_end{padding-inline-end:3px}.g-text-input_size_xl{--_--error-icon-padding-block:13px;--_--error-icon-padding-inline:0 13px;--_--border-radius:var(--g-border-radius-xl)}.g-text-input_size_xl .g-text-input__control{--_--input-control-border-width:var( - --g-text-input-border-width,var(--g-text-area-border-width,1px) - );height:calc(44px - var(--_--input-control-border-width)*2);padding:11px 12px}.g-text-input_size_xl .g-text-input__control,.g-text-input_size_xl .g-text-input__label{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-text-input_size_xl .g-text-input__label{font-weight:var(--g-text-accent-font-weight);padding-block:11px;padding-inline:12px 4px}.g-text-input_size_xl.g-text-input_has-start-content .g-text-input__label{padding-inline-start:3px}.g-text-input_size_xl .g-text-input__additional-content{height:42px}.g-text-input_size_xl .g-text-input__additional-content_placement_start{padding-inline-start:3px}.g-text-input_size_xl .g-text-input__additional-content_placement_end{padding-inline-end:3px}.g-text-input_view_normal{--_--border-color:var(--g-color-line-generic);--_--border-color-hover:var(--g-color-line-generic-hover);--_--border-color-active:var(--g-color-line-generic-active)}.g-text-input_view_clear{--_--border-color:#0000;--_--border-color-hover:#0000;--_--border-color-active:#0000;--_--border-radius:0}.g-text-input_view_clear .g-text-input__content{border-inline:0}.g-text-input_view_clear .g-text-input__control{padding-inline:0}.g-text-input.g-text-input_pin_round-round .g-text-input__content{border-radius:var(--g-text-input-border-radius,var(--_--border-radius))}.g-text-input.g-text-input_pin_brick-brick .g-text-input__content{border-radius:0}.g-text-input.g-text-input_pin_clear-clear .g-text-input__content{border-inline:0;border-radius:0}.g-text-input.g-text-input_pin_circle-circle .g-text-input__content{border-radius:100px}.g-text-input.g-text-input_pin_round-brick .g-text-input__content{border-end-end-radius:0;border-end-start-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-start-end-radius:0;border-start-start-radius:var(--g-text-input-border-radius,var(--_--border-radius))}.g-text-input.g-text-input_pin_brick-round .g-text-input__content{border-end-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-end-start-radius:0;border-start-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-text-input.g-text-input_pin_round-clear .g-text-input__content{border-end-end-radius:0;border-end-start-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-inline-end:0;border-start-end-radius:0;border-start-start-radius:var(--g-text-input-border-radius,var(--_--border-radius))}.g-text-input.g-text-input_pin_clear-round .g-text-input__content{border-end-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-end-start-radius:0;border-inline-start:0;border-start-end-radius:var(--g-text-input-border-radius,var(--_--border-radius));border-start-start-radius:0}.g-text-input.g-text-input_pin_brick-clear .g-text-input__content{border-inline-end:0;border-radius:0}.g-text-input.g-text-input_pin_clear-brick .g-text-input__content{border-inline-start:0;border-radius:0}.g-text-input.g-text-input_pin_circle-brick .g-text-input__content{border-end-end-radius:0;border-end-start-radius:100px;border-start-end-radius:0;border-start-start-radius:100px}.g-text-input.g-text-input_pin_brick-circle .g-text-input__content{border-end-end-radius:100px;border-end-start-radius:0;border-start-end-radius:100px;border-start-start-radius:0}.g-text-input.g-text-input_pin_circle-clear .g-text-input__content{border-end-end-radius:0;border-end-start-radius:100px;border-inline-end:0;border-start-end-radius:0;border-start-start-radius:100px}.g-text-input.g-text-input_pin_clear-circle .g-text-input__content{border-end-end-radius:100px;border-end-start-radius:0;border-inline-start:0;border-start-end-radius:100px;border-start-start-radius:0}.g-text-input_disabled{--_--text-color:var(--g-color-text-hint);--_--background-color:var(--g-color-base-generic-accent-disabled);--_--border-color:#0000;--_--border-color-hover:#0000;--_--border-color-active:#0000}.g-text-input_has-scrollbar .g-text-input__clear{inset-inline-end:var(--g-scrollbar-width)}.g-text-input_has-start-content .g-text-input__control{padding-inline-start:2px}.g-text-input_has-end-content .g-text-input__control{padding-inline-end:2px}.g-text-input_has-unstable-end-content{--_--error-icon-padding-inline:0}.g-text-input_state_error.g-text-input_view_normal .g-text-input__content,.g-text-input_state_error.g-text-input_view_normal .g-text-input__content:focus-within,.g-text-input_state_error.g-text-input_view_normal .g-text-input__content:hover{border-color:var(--g-color-line-danger)}.g-text-input_state_error.g-text-input_view_normal .g-text-input__content:focus-within{--_--focus-outline-color:var(--g-color-line-danger)}.g-text-input_state_error.g-text-input_view_clear .g-text-input__content,.g-text-input_state_error.g-text-input_view_clear .g-text-input__content:focus-within,.g-text-input_state_error.g-text-input_view_clear .g-text-input__content:hover{border-block-end:1px solid var(--g-color-line-danger)}.g-text-input_state_error.g-text-input_view_clear .g-text-input__content:focus-within{--_--focus-outline-color:var(--g-color-line-danger)}.g-clear-button{--g-button-text-color:var(--g-color-text-hint);--g-button-text-color-hover:var(--g-color-text-primary);--g-button-background-color:#0000;--g-button-background-color-hover:#0000}.g-link{-webkit-tap-highlight-color:rgba(0,0,0,0);border-radius:var(--g-focus-border-radius);cursor:pointer;text-decoration:none;touch-action:manipulation}.g-link:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-link_view_normal{color:var(--g-color-text-link)}.g-link_view_primary{color:var(--g-color-text-primary)}.g-link_view_secondary{color:var(--g-color-text-secondary)}.g-link_view_normal:hover,.g-link_view_primary:hover,.g-link_view_secondary:hover{color:var(--g-color-text-link-hover)}.g-link_visitable:visited{color:var(--g-color-text-link-visited)}.g-link_visitable:visited:hover{color:var(--g-color-text-link-visited-hover)}.g-link_underline{text-decoration:underline}.g-popover{display:inline-block;position:relative}.g-popover:not(.g-popover_disabled){cursor:pointer}.g-popover__handler{display:inline-block}.g-popover__tooltip{--_--padding:16px;--_--close-offset:8px;--_--close-size:24px}.g-popover__tooltip-popup-content{box-sizing:border-box;cursor:default;max-width:var(--g-popover-max-width,300px);min-height:40px;padding:var(--g-popover-padding,var(--_--padding))}.g-popover__tooltip-title{display:inline-flex;font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height);margin:0 0 12px}.g-popover__tooltip-buttons{display:flex;flex-wrap:wrap;gap:5px;margin-block-start:20px}.g-popover__tooltip-button{flex:1 1}.g-popover__tooltip-close{inset-block-start:var(--_--close-offset);inset-inline-end:var(--_--close-offset);position:absolute}.g-popover__tooltip-content{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height);overflow-wrap:break-word}.g-popover__tooltip-content_secondary{opacity:.7}.g-popover__tooltip-links>*{margin-block-start:8px}.g-popover__tooltip-links>:first-child{margin-block-start:0}.g-popover__tooltip-content+.g-popover__tooltip-links>:first-child{margin-block-start:12px}.g-popover__tooltip-link{display:inline-block;font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-popover__tooltip_theme_announcement .g-popover__tooltip_theme_announcement,.g-popover__tooltip_theme_announcement.g-popover__tooltip_theme_info,.g-popover__tooltip_theme_info .g-popover__tooltip_theme_announcement,.g-popover__tooltip_theme_info.g-popover__tooltip_theme_info{color:var(--g-color-text-primary)}.g-popover__tooltip_force-links-appearance.g-popover__tooltip_theme_info .g-popover__tooltip-content a:not(.g-button),.g-popover__tooltip_theme_announcement .g-popover__tooltip-content a:not(.g-button){color:var(--g-color-text-link);text-decoration:none}.g-popover__tooltip_force-links-appearance.g-popover__tooltip_theme_info .g-popover__tooltip-content a:not(.g-button):hover,.g-popover__tooltip_theme_announcement .g-popover__tooltip-content a:not(.g-button):hover{color:var(--g-color-text-link-hover)}.g-popover__tooltip_theme_announcement{--g-popup-background-color:var(--g-color-base-simple-hover-solid);--g-popup-border-color:var(--g-color-base-simple-hover-solid)}.g-popover__tooltip_theme_special{--g-popup-background-color:var(--g-color-base-brand);--g-popup-border-color:var(--g-color-base-brand);color:var(--g-color-text-light-primary)}.g-popover__tooltip_theme_special .g-popover__tooltip-content a:not(.g-button){color:var(--g-color-text-light-primary);font-weight:var(--g-text-accent-font-weight)}.g-popover__tooltip_theme_special .g-popover__tooltip-content a:not(.g-button):hover{color:var(--g-color-text-light-secondary)}.g-popover__tooltip_theme_special .g-link{color:var(--g-color-text-light-primary)}.g-popover__tooltip_theme_special .g-link:hover{color:var(--g-color-text-light-secondary)}.g-popover__tooltip_size_l{--_--padding:24px}.g-popover__tooltip_size_l .g-popover__tooltip-title{font-family:var(--g-text-header-font-family);font-size:var(--g-text-header-1-font-size);font-weight:var(--g-text-header-font-weight);line-height:var(--g-text-header-1-line-height)}.g-popover__tooltip_size_l .g-popover__tooltip-content{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-2-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-2-line-height)}.g-popover__tooltip_with-close .g-popover__tooltip-content,.g-popover__tooltip_with-close .g-popover__tooltip-title{padding-inline-end:calc(var(--_--close-offset) + var(--_--close-size) - var(--_--padding))}.g-popup{--_--background-color:var(--g-popup-background-color,var(--g-color-base-float));--_--border-color:var(--g-popup-border-color,var(--g-color-line-generic-solid));--_--border-width:var(--g-popup-border-width,1px);visibility:hidden;z-index:1000}.g-popup_exit_active,.g-popup_open{visibility:visible}.g-popup_exit_active[data-popper-placement*=bottom] .g-popup__content{animation-name:g-popup-bottom}.g-popup_exit_active[data-popper-placement*=top] .g-popup__content{animation-name:g-popup-top}.g-popup_exit_active[data-popper-placement*=left] .g-popup__content{animation-name:g-popup-left}.g-popup_exit_active[data-popper-placement*=right] .g-popup__content{animation-name:g-popup-right}.g-popup_appear_active[data-popper-placement*=bottom] .g-popup__content,.g-popup_enter_active[data-popper-placement*=bottom] .g-popup__content{animation-name:g-popup-bottom-open}.g-popup_appear_active[data-popper-placement*=top] .g-popup__content,.g-popup_enter_active[data-popper-placement*=top] .g-popup__content{animation-name:g-popup-top-open}.g-popup_appear_active[data-popper-placement*=left] .g-popup__content,.g-popup_enter_active[data-popper-placement*=left] .g-popup__content{animation-name:g-popup-left-open}.g-popup_appear_active[data-popper-placement*=right] .g-popup__content,.g-popup_enter_active[data-popper-placement*=right] .g-popup__content{animation-name:g-popup-right-open}.g-popup[data-popper-placement*=bottom] .g-popup__arrow{inset-block-start:-9px}.g-popup[data-popper-placement*=top] .g-popup__arrow{inset-block-end:-9px}.g-popup[data-popper-placement*=top] .g-popup__arrow-content{transform:rotate(180deg)}.g-popup[data-popper-placement*=left] .g-popup__arrow{right:-9px}.g-popup[data-popper-placement*=left] .g-popup__arrow-content{transform:rotate(90deg)}.g-popup[data-popper-placement*=right] .g-popup__arrow{left:-9px}.g-popup[data-popper-placement*=right] .g-popup__arrow-content{transform:rotate(-90deg)}.g-popup__content{animation-duration:.1s;animation-fill-mode:forwards;animation-timing-function:ease-out;background-color:var(--_--background-color);border-radius:4px;box-shadow:0 0 0 var(--_--border-width) var(--_--border-color),0 8px 20px var(--_--border-width) var(--g-color-sfx-shadow);outline:none;position:relative}.g-popup__content>.g-popup__arrow+*,.g-popup__content>:first-child:not(.g-popup__arrow){border-start-end-radius:inherit;border-start-start-radius:inherit}.g-popup__content>:last-child{border-end-end-radius:inherit;border-end-start-radius:inherit}.g-popup__arrow-content{display:flex;height:18px;overflow:hidden;position:relative;width:18px}.g-popup__arrow-circle-wrapper{background-color:initial;height:9px;overflow:hidden;position:relative;width:9px}.g-popup__arrow-circle{border-radius:50%;box-shadow:inset 0 0 0 calc(5px - var(--_--border-width)) var(--_--background-color),inset 0 0 0 5px var(--_--border-color);box-sizing:border-box;height:30px;position:absolute;width:28px}.g-popup__arrow-circle_left{inset-block-end:-4px;inset-inline-end:-5px}.g-popup__arrow-circle_right{inset-block-end:-4px;inset-inline-start:-5px}@keyframes g-popup-bottom{0%{opacity:1;transform:translateY(0)}to{opacity:0;transform:translateY(10px)}}@keyframes g-popup-bottom-open{0%{opacity:0;transform:translateY(10px)}to{opacity:1;transform:translateY(0)}}@keyframes g-popup-top{0%{opacity:1;transform:translateY(0)}to{opacity:0;transform:translateY(-10px)}}@keyframes g-popup-top-open{0%{opacity:0;transform:translateY(-10px)}to{opacity:1;transform:translateY(0)}}@keyframes g-popup-left{0%{opacity:1;transform:translateX(0)}to{opacity:0;transform:translateX(-10px)}}@keyframes g-popup-left-open{0%{opacity:0;transform:translateX(-10px)}to{opacity:1;transform:translateX(0)}}@keyframes g-popup-right{0%{opacity:1;transform:translateX(0)}to{opacity:0;transform:translateX(10px)}}@keyframes g-popup-right-open{0%{opacity:0;transform:translateX(10px)}to{opacity:1;transform:translateX(0)}}.g-portal__theme-wrapper{display:contents}@keyframes g-pulse{50%{opacity:15%}}.g-loader{align-items:center;display:inline-flex}.g-loader__center,.g-loader__left,.g-loader__right{animation:g-pulse .8s ease infinite;background:var(--g-color-base-brand)}.g-loader__left{animation-delay:.2s}.g-loader__center{animation-delay:.4s}.g-loader__right{animation-delay:.6s}.g-loader_size_s .g-loader__left{height:13.33333px;width:5px}.g-loader_size_s .g-loader__center{height:20px;margin-inline-start:5px;width:5px}.g-loader_size_s .g-loader__right{height:13.33333px;margin-inline-start:5px;width:5px}.g-loader_size_m .g-loader__left{height:18.66667px;width:7px}.g-loader_size_m .g-loader__center{height:28px;margin-inline-start:7px;width:7px}.g-loader_size_m .g-loader__right{height:18.66667px;margin-inline-start:7px;width:7px}.g-loader_size_l .g-loader__left{height:24px;width:9px}.g-loader_size_l .g-loader__center{height:36px;margin-inline-start:9px;width:9px}.g-loader_size_l .g-loader__right{height:24px;margin-inline-start:9px;width:9px}.g-s__m_0{margin:var(--g-spacing-0)}.g-s__mr_0{margin-inline-end:var(--g-spacing-0)}.g-s__ml_0{margin-inline-start:var(--g-spacing-0)}.g-s__mt_0{margin-block-start:var(--g-spacing-0)}.g-s__mb_0{margin-block-end:var(--g-spacing-0)}.g-s__mx_0{margin-inline:var(--g-spacing-0)}.g-s__my_0{margin-block:var(--g-spacing-0)}.g-s__p_0{padding:var(--g-spacing-0)}.g-s__pl_0{padding-inline-start:var(--g-spacing-0)}.g-s__pr_0{padding-inline-end:var(--g-spacing-0)}.g-s__pb_0{padding-block-end:var(--g-spacing-0)}.g-s__pt_0{padding-block-start:var(--g-spacing-0)}.g-s__py_0{padding-block:var(--g-spacing-0)}.g-s__px_0{padding-inline:var(--g-spacing-0)}.g-s__m_half{margin:var(--g-spacing-half)}.g-s__mr_half{margin-inline-end:var(--g-spacing-half)}.g-s__ml_half{margin-inline-start:var(--g-spacing-half)}.g-s__mt_half{margin-block-start:var(--g-spacing-half)}.g-s__mb_half{margin-block-end:var(--g-spacing-half)}.g-s__mx_half{margin-inline:var(--g-spacing-half)}.g-s__my_half{margin-block:var(--g-spacing-half)}.g-s__p_half{padding:var(--g-spacing-half)}.g-s__pl_half{padding-inline-start:var(--g-spacing-half)}.g-s__pr_half{padding-inline-end:var(--g-spacing-half)}.g-s__pb_half{padding-block-end:var(--g-spacing-half)}.g-s__pt_half{padding-block-start:var(--g-spacing-half)}.g-s__py_half{padding-block:var(--g-spacing-half)}.g-s__px_half{padding-inline:var(--g-spacing-half)}.g-s__m_1{margin:var(--g-spacing-1)}.g-s__mr_1{margin-inline-end:var(--g-spacing-1)}.g-s__ml_1{margin-inline-start:var(--g-spacing-1)}.g-s__mt_1{margin-block-start:var(--g-spacing-1)}.g-s__mb_1{margin-block-end:var(--g-spacing-1)}.g-s__mx_1{margin-inline:var(--g-spacing-1)}.g-s__my_1{margin-block:var(--g-spacing-1)}.g-s__p_1{padding:var(--g-spacing-1)}.g-s__pl_1{padding-inline-start:var(--g-spacing-1)}.g-s__pr_1{padding-inline-end:var(--g-spacing-1)}.g-s__pb_1{padding-block-end:var(--g-spacing-1)}.g-s__pt_1{padding-block-start:var(--g-spacing-1)}.g-s__py_1{padding-block:var(--g-spacing-1)}.g-s__px_1{padding-inline:var(--g-spacing-1)}.g-s__m_2{margin:var(--g-spacing-2)}.g-s__mr_2{margin-inline-end:var(--g-spacing-2)}.g-s__ml_2{margin-inline-start:var(--g-spacing-2)}.g-s__mt_2{margin-block-start:var(--g-spacing-2)}.g-s__mb_2{margin-block-end:var(--g-spacing-2)}.g-s__mx_2{margin-inline:var(--g-spacing-2)}.g-s__my_2{margin-block:var(--g-spacing-2)}.g-s__p_2{padding:var(--g-spacing-2)}.g-s__pl_2{padding-inline-start:var(--g-spacing-2)}.g-s__pr_2{padding-inline-end:var(--g-spacing-2)}.g-s__pb_2{padding-block-end:var(--g-spacing-2)}.g-s__pt_2{padding-block-start:var(--g-spacing-2)}.g-s__py_2{padding-block:var(--g-spacing-2)}.g-s__px_2{padding-inline:var(--g-spacing-2)}.g-s__m_3{margin:var(--g-spacing-3)}.g-s__mr_3{margin-inline-end:var(--g-spacing-3)}.g-s__ml_3{margin-inline-start:var(--g-spacing-3)}.g-s__mt_3{margin-block-start:var(--g-spacing-3)}.g-s__mb_3{margin-block-end:var(--g-spacing-3)}.g-s__mx_3{margin-inline:var(--g-spacing-3)}.g-s__my_3{margin-block:var(--g-spacing-3)}.g-s__p_3{padding:var(--g-spacing-3)}.g-s__pl_3{padding-inline-start:var(--g-spacing-3)}.g-s__pr_3{padding-inline-end:var(--g-spacing-3)}.g-s__pb_3{padding-block-end:var(--g-spacing-3)}.g-s__pt_3{padding-block-start:var(--g-spacing-3)}.g-s__py_3{padding-block:var(--g-spacing-3)}.g-s__px_3{padding-inline:var(--g-spacing-3)}.g-s__m_4{margin:var(--g-spacing-4)}.g-s__mr_4{margin-inline-end:var(--g-spacing-4)}.g-s__ml_4{margin-inline-start:var(--g-spacing-4)}.g-s__mt_4{margin-block-start:var(--g-spacing-4)}.g-s__mb_4{margin-block-end:var(--g-spacing-4)}.g-s__mx_4{margin-inline:var(--g-spacing-4)}.g-s__my_4{margin-block:var(--g-spacing-4)}.g-s__p_4{padding:var(--g-spacing-4)}.g-s__pl_4{padding-inline-start:var(--g-spacing-4)}.g-s__pr_4{padding-inline-end:var(--g-spacing-4)}.g-s__pb_4{padding-block-end:var(--g-spacing-4)}.g-s__pt_4{padding-block-start:var(--g-spacing-4)}.g-s__py_4{padding-block:var(--g-spacing-4)}.g-s__px_4{padding-inline:var(--g-spacing-4)}.g-s__m_5{margin:var(--g-spacing-5)}.g-s__mr_5{margin-inline-end:var(--g-spacing-5)}.g-s__ml_5{margin-inline-start:var(--g-spacing-5)}.g-s__mt_5{margin-block-start:var(--g-spacing-5)}.g-s__mb_5{margin-block-end:var(--g-spacing-5)}.g-s__mx_5{margin-inline:var(--g-spacing-5)}.g-s__my_5{margin-block:var(--g-spacing-5)}.g-s__p_5{padding:var(--g-spacing-5)}.g-s__pl_5{padding-inline-start:var(--g-spacing-5)}.g-s__pr_5{padding-inline-end:var(--g-spacing-5)}.g-s__pb_5{padding-block-end:var(--g-spacing-5)}.g-s__pt_5{padding-block-start:var(--g-spacing-5)}.g-s__py_5{padding-block:var(--g-spacing-5)}.g-s__px_5{padding-inline:var(--g-spacing-5)}.g-s__m_6{margin:var(--g-spacing-6)}.g-s__mr_6{margin-inline-end:var(--g-spacing-6)}.g-s__ml_6{margin-inline-start:var(--g-spacing-6)}.g-s__mt_6{margin-block-start:var(--g-spacing-6)}.g-s__mb_6{margin-block-end:var(--g-spacing-6)}.g-s__mx_6{margin-inline:var(--g-spacing-6)}.g-s__my_6{margin-block:var(--g-spacing-6)}.g-s__p_6{padding:var(--g-spacing-6)}.g-s__pl_6{padding-inline-start:var(--g-spacing-6)}.g-s__pr_6{padding-inline-end:var(--g-spacing-6)}.g-s__pb_6{padding-block-end:var(--g-spacing-6)}.g-s__pt_6{padding-block-start:var(--g-spacing-6)}.g-s__py_6{padding-block:var(--g-spacing-6)}.g-s__px_6{padding-inline:var(--g-spacing-6)}.g-s__m_7{margin:var(--g-spacing-7)}.g-s__mr_7{margin-inline-end:var(--g-spacing-7)}.g-s__ml_7{margin-inline-start:var(--g-spacing-7)}.g-s__mt_7{margin-block-start:var(--g-spacing-7)}.g-s__mb_7{margin-block-end:var(--g-spacing-7)}.g-s__mx_7{margin-inline:var(--g-spacing-7)}.g-s__my_7{margin-block:var(--g-spacing-7)}.g-s__p_7{padding:var(--g-spacing-7)}.g-s__pl_7{padding-inline-start:var(--g-spacing-7)}.g-s__pr_7{padding-inline-end:var(--g-spacing-7)}.g-s__pb_7{padding-block-end:var(--g-spacing-7)}.g-s__pt_7{padding-block-start:var(--g-spacing-7)}.g-s__py_7{padding-block:var(--g-spacing-7)}.g-s__px_7{padding-inline:var(--g-spacing-7)}.g-s__m_8{margin:var(--g-spacing-8)}.g-s__mr_8{margin-inline-end:var(--g-spacing-8)}.g-s__ml_8{margin-inline-start:var(--g-spacing-8)}.g-s__mt_8{margin-block-start:var(--g-spacing-8)}.g-s__mb_8{margin-block-end:var(--g-spacing-8)}.g-s__mx_8{margin-inline:var(--g-spacing-8)}.g-s__my_8{margin-block:var(--g-spacing-8)}.g-s__p_8{padding:var(--g-spacing-8)}.g-s__pl_8{padding-inline-start:var(--g-spacing-8)}.g-s__pr_8{padding-inline-end:var(--g-spacing-8)}.g-s__pb_8{padding-block-end:var(--g-spacing-8)}.g-s__pt_8{padding-block-start:var(--g-spacing-8)}.g-s__py_8{padding-block:var(--g-spacing-8)}.g-s__px_8{padding-inline:var(--g-spacing-8)}.g-s__m_9{margin:var(--g-spacing-9)}.g-s__mr_9{margin-inline-end:var(--g-spacing-9)}.g-s__ml_9{margin-inline-start:var(--g-spacing-9)}.g-s__mt_9{margin-block-start:var(--g-spacing-9)}.g-s__mb_9{margin-block-end:var(--g-spacing-9)}.g-s__mx_9{margin-inline:var(--g-spacing-9)}.g-s__my_9{margin-block:var(--g-spacing-9)}.g-s__p_9{padding:var(--g-spacing-9)}.g-s__pl_9{padding-inline-start:var(--g-spacing-9)}.g-s__pr_9{padding-inline-end:var(--g-spacing-9)}.g-s__pb_9{padding-block-end:var(--g-spacing-9)}.g-s__pt_9{padding-block-start:var(--g-spacing-9)}.g-s__py_9{padding-block:var(--g-spacing-9)}.g-s__px_9{padding-inline:var(--g-spacing-9)}.g-s__m_10{margin:var(--g-spacing-10)}.g-s__mr_10{margin-inline-end:var(--g-spacing-10)}.g-s__ml_10{margin-inline-start:var(--g-spacing-10)}.g-s__mt_10{margin-block-start:var(--g-spacing-10)}.g-s__mb_10{margin-block-end:var(--g-spacing-10)}.g-s__mx_10{margin-inline:var(--g-spacing-10)}.g-s__my_10{margin-block:var(--g-spacing-10)}.g-s__p_10{padding:var(--g-spacing-10)}.g-s__pl_10{padding-inline-start:var(--g-spacing-10)}.g-s__pr_10{padding-inline-end:var(--g-spacing-10)}.g-s__pb_10{padding-block-end:var(--g-spacing-10)}.g-s__pt_10{padding-block-start:var(--g-spacing-10)}.g-s__py_10{padding-block:var(--g-spacing-10)}.g-s__px_10{padding-inline:var(--g-spacing-10)}.g-box{box-sizing:border-box}.g-box_overflow_hidden{overflow:hidden}.g-box_overflow_auto{overflow:auto}.g-box_overflow_x{overflow:hidden auto}.g-box_overflow_y{overflow:auto hidden}.g-flex{display:flex}.g-flex_inline{display:inline-flex}.g-flex_center-content{align-items:center;justify-content:center}.g-flex_s_0{margin-block-start:calc(var(--g-spacing-0)*-1)!important;margin-inline-start:calc(var(--g-spacing-0)*-1)!important}.g-flex_s_0>*{padding-block-start:var(--g-spacing-0)!important;padding-inline-start:var(--g-spacing-0)!important}.g-flex_s_half{margin-block-start:calc(var(--g-spacing-half)*-1)!important;margin-inline-start:calc(var(--g-spacing-half)*-1)!important}.g-flex_s_half>*{padding-block-start:var(--g-spacing-half)!important;padding-inline-start:var(--g-spacing-half)!important}.g-flex_s_1{margin-block-start:calc(var(--g-spacing-1)*-1)!important;margin-inline-start:calc(var(--g-spacing-1)*-1)!important}.g-flex_s_1>*{padding-block-start:var(--g-spacing-1)!important;padding-inline-start:var(--g-spacing-1)!important}.g-flex_s_2{margin-block-start:calc(var(--g-spacing-2)*-1)!important;margin-inline-start:calc(var(--g-spacing-2)*-1)!important}.g-flex_s_2>*{padding-block-start:var(--g-spacing-2)!important;padding-inline-start:var(--g-spacing-2)!important}.g-flex_s_3{margin-block-start:calc(var(--g-spacing-3)*-1)!important;margin-inline-start:calc(var(--g-spacing-3)*-1)!important}.g-flex_s_3>*{padding-block-start:var(--g-spacing-3)!important;padding-inline-start:var(--g-spacing-3)!important}.g-flex_s_4{margin-block-start:calc(var(--g-spacing-4)*-1)!important;margin-inline-start:calc(var(--g-spacing-4)*-1)!important}.g-flex_s_4>*{padding-block-start:var(--g-spacing-4)!important;padding-inline-start:var(--g-spacing-4)!important}.g-flex_s_5{margin-block-start:calc(var(--g-spacing-5)*-1)!important;margin-inline-start:calc(var(--g-spacing-5)*-1)!important}.g-flex_s_5>*{padding-block-start:var(--g-spacing-5)!important;padding-inline-start:var(--g-spacing-5)!important}.g-flex_s_6{margin-block-start:calc(var(--g-spacing-6)*-1)!important;margin-inline-start:calc(var(--g-spacing-6)*-1)!important}.g-flex_s_6>*{padding-block-start:var(--g-spacing-6)!important;padding-inline-start:var(--g-spacing-6)!important}.g-flex_s_7{margin-block-start:calc(var(--g-spacing-7)*-1)!important;margin-inline-start:calc(var(--g-spacing-7)*-1)!important}.g-flex_s_7>*{padding-block-start:var(--g-spacing-7)!important;padding-inline-start:var(--g-spacing-7)!important}.g-flex_s_8{margin-block-start:calc(var(--g-spacing-8)*-1)!important;margin-inline-start:calc(var(--g-spacing-8)*-1)!important}.g-flex_s_8>*{padding-block-start:var(--g-spacing-8)!important;padding-inline-start:var(--g-spacing-8)!important}.g-flex_s_9{margin-block-start:calc(var(--g-spacing-9)*-1)!important;margin-inline-start:calc(var(--g-spacing-9)*-1)!important}.g-flex_s_9>*{padding-block-start:var(--g-spacing-9)!important;padding-inline-start:var(--g-spacing-9)!important}.g-flex_s_10{margin-block-start:calc(var(--g-spacing-10)*-1)!important;margin-inline-start:calc(var(--g-spacing-10)*-1)!important}.g-flex_s_10>*{padding-block-start:var(--g-spacing-10)!important;padding-inline-start:var(--g-spacing-10)!important}.kv-ydb-internal-user{align-items:center;display:flex;flex-grow:1;justify-content:space-between;line-height:var(--g-text-body-2-line-height);margin-left:16px}.kv-ydb-internal-user__user-info-wrapper{display:flex;flex-direction:column}.kv-ydb-internal-user__ydb-internal-user-title{font-weight:500}.kv-ydb-internal-user__ydb-user-wrapper{padding:10px;width:300px}.ydb-link-with-icon{align-items:center;display:flex;flex-wrap:nowrap;white-space:nowrap}.ydb-node-endpoints-tooltip-content .info-viewer__value{min-width:70px}.ydb-node-endpoints-tooltip-content__list-container{padding-right:20px}.ydb-node-endpoints-tooltip-content__definition{text-align:right;word-break:break-word}.g-clipboard-button__icon{pointer-events:none}.g-action-tooltip{--g-popup-border-width:0;--g-popup-background-color:var(--g-color-base-float-heavy)}.g-action-tooltip__content{box-sizing:border-box;color:var(--g-color-text-light-primary);max-width:300px;padding:6px 12px}.g-action-tooltip__heading{align-items:baseline;display:flex;justify-content:space-between}.g-action-tooltip__title{color:var(--g-color-text-light-primary)}.g-action-tooltip__hotkey{margin-inline-start:8px}.g-action-tooltip__description{color:var(--g-color-text-light-secondary);margin-block-start:4px}.g-hotkey{border-radius:4px;padding:1px 5px}.g-hotkey,.g-hotkey kbd{font-family:var(--g-text-body-font-family);font-size:var(--g-text-body-1-font-size);font-weight:var(--g-text-body-font-weight);line-height:var(--g-text-body-1-line-height)}.g-hotkey_view_light{background-color:var(--g-color-base-generic)}.g-hotkey_view_light .g-hotkey__plus{color:var(--g-color-text-hint)}.g-hotkey_view_dark{background-color:var(--g-color-base-light-simple-hover);color:var(--g-color-text-light-complementary)}.g-hotkey_view_dark .g-hotkey__plus{color:var(--g-color-text-light-hint)}.g-help-mark__button{background:none;border:none;color:inherit;color:var(--g-color-text-hint);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.g-help-mark__button:focus-visible{border-radius:50%;outline:2px solid var(--g-color-line-focus)}.g-definition-list{--_--item-block-start:var(--g-spacing-4);--_--term-width:300px;margin:0}.g-definition-list__item{align-items:baseline;display:flex;gap:var(--g-spacing-1)}.g-definition-list__item+.g-definition-list__item{margin-block-start:var(--g-definition-list-item-gap,var(--_--item-block-start))}.g-definition-list__term-container{align-items:baseline;display:flex;flex:0 0 auto;max-width:var(--_--term-width);overflow:hidden;position:relative;width:var(--_--term-width)}.g-definition-list__term-wrapper{color:var(--g-color-text-secondary)}.g-definition-list__dots{border-block-end:1px dotted var(--g-color-line-generic-active);box-sizing:border-box;flex:1 0 auto;margin:0 2px;min-width:25px}.g-definition-list__definition{flex:0 1 auto;margin:0}.g-definition-list_responsive .g-definition-list__term-container{--_--term-width:auto;flex:1 0 min-content}.g-definition-list_vertical{--_--item-block-start:var(--g-spacing-3);--_--term-width:auto}.g-definition-list_vertical .g-definition-list__term-container{flex:1 0 auto}.g-definition-list_vertical .g-definition-list__item{flex-direction:column;gap:var(--g-spacing-half)}.g-definition-list__copy-container{align-items:center;display:inline-flex;margin-inline-end:calc(var(--g-spacing-7)*-1);padding-inline-end:var(--g-spacing-7);position:relative}.g-definition-list__copy-container:hover .g-definition-list__copy-button{opacity:1}.g-definition-list__copy-button{display:inline-block;inset-inline-end:0;margin-inline-start:10px;opacity:0;position:absolute}.g-definition-list__copy-button:focus-visible{opacity:1}.info-viewer{--ydb-info-viewer-font-size:var(--g-text-body-2-font-size);--ydb-info-viewer-line-height:var(--g-text-body-2-line-height);--ydb-info-viewer-title-font-weight:600;--ydb-info-viewer-title-margin:15px 0 10px;--ydb-info-viewer-items-gap:7px;font-size:var(--ydb-info-viewer-font-size);line-height:var(--ydb-info-viewer-line-height)}.info-viewer__title{font-weight:var(--ydb-info-viewer-title-font-weight);margin:var(--ydb-info-viewer-title-margin)}.info-viewer__items{display:flex;flex-direction:column;gap:var(--ydb-info-viewer-items-gap);max-width:100%}.info-viewer__row{align-items:baseline;display:flex;max-width:100%;padding-top:4px}.info-viewer__label{align-items:baseline;color:var(--g-color-text-secondary);display:flex;flex:0 1 auto;min-width:200px;white-space:nowrap}.info-viewer__label-text_multiline{max-width:180px;overflow:visible;white-space:normal}.info-viewer__dots{border-bottom:1px dotted var(--g-color-text-secondary);display:flex;flex:1 1 auto;margin:0 2px}.info-viewer__value{display:flex;min-width:130px;word-break:break-all}.info-viewer_size_s{--ydb-info-viewer-font-size:var(--g-text-body-1-font-size);--ydb-info-viewer-line-height:var(--g-text-body-1-line-height);--ydb-info-viewer-title-font-weight:500;--ydb-info-viewer-title-margin:0 0 4px;--ydb-info-viewer-items-gap:4px}.info-viewer_size_s .info-viewer__row{height:auto}.info-viewer_size_s .info-viewer__label{min-width:85px}.ydb-cell-with-popover{display:inline-flex;max-width:100%}.ydb-cell-with-popover_full-width{display:flex}.ydb-cell-with-popover__popover{display:inline-block;max-width:100%;overflow:hidden;text-overflow:ellipsis;vertical-align:middle;white-space:nowrap}.ydb-cell-with-popover__popover .g-popover__handler{display:inline}.ydb-cell-with-popover__popover_full-width{width:100%}.popup2{animation:none!important;max-width:300px}.histogram-tooltip,.node-tootltip{padding:10px}.histogram-tooltip__label,.node-tootltip__label{color:var(--g-color-text-secondary);padding-right:15px}.cell-tooltip{padding:10px;word-break:break-word}.empty-state{padding:20px}.empty-state_size_m{height:400px}.empty-state__wrapper{display:grid;grid-template-areas:"image title" "image description" "image actions"}.empty-state__wrapper_size_s{height:120px;width:460px}.empty-state__wrapper_size_m{height:240px;width:800px}.empty-state__wrapper_position_center{margin:0 auto;position:relative}.empty-state__image{color:var(--g-color-base-info-light-hover);grid-area:image;justify-self:end;margin-right:60px}.g-root_theme_dark .empty-state__image{color:var(--g-color-base-generic)}.empty-state__title{align-self:center;font-weight:500;grid-area:title}.empty-state__title_size_s{font-size:var(--g-text-subheader-3-font-size);line-height:var(--g-text-subheader-3-line-height)}.empty-state__title_size_m{font-size:var(--g-text-header-2-font-size);line-height:var(--g-text-header-2-line-height)}.empty-state__description{font-size:var(--g-text-body-2-font-size);grid-area:description;line-height:var(--g-text-body-2-line-height)}.empty-state__actions{grid-area:actions}.empty-state__actions>*{margin-right:8px}.ydb-loader{flex:1 1 auto}.authentication,.ydb-loader{align-items:center;display:flex;height:100%;justify-content:center}.authentication{background-blend-mode:normal;background-color:#b8d4fd1a;background-image:radial-gradient(at 0 100%,#0066ff26 20%,#f7f7f700 40%),radial-gradient(at 55% 0,#0066ff26 20%,#f7f7f700 40%),radial-gradient(at 110% 100%,#0066ff26 20%,#f7f7f700 40%)}.authentication .g-text-input{display:flex}.authentication__header{align-items:center;display:flex;font-size:var(--g-text-body-1-font-size);justify-content:space-between;line-height:var(--g-text-header-1-line-height);width:100%}.authentication__logo{align-items:center;display:flex;font-size:16px;font-weight:600;gap:8px}.authentication__title{font-size:var(--g-text-header-2-font-size);font-weight:600;line-height:var(--g-text-header-2-line-height);margin:34px 0 16px}.authentication__form-wrapper{align-items:center;background-color:var(--g-color-base-background);border-radius:16px;display:flex;flex-direction:column;flex-shrink:0;justify-content:center;min-width:320px;padding:40px;width:400px}.authentication__field-wrapper{align-items:flex-start;display:flex;justify-content:space-between;margin-bottom:16px;width:320px}.authentication__field-wrapper .g-text-input_state_error{flex-direction:column}.authentication__button-sign-in{display:inline-flex;justify-content:center}.authentication__show-password-button{margin-left:4px}.authentication__close{position:absolute;right:40px;top:40px}.ydb-connect-to-db__dialog-tabs,.ydb-connect-to-db__docs{margin-top:var(--g-spacing-4)}.ydb-connect-to-db__snippet-container{height:270px}.g-dialog-btn-close{inset-block-start:14px;inset-inline-end:14px;position:absolute;z-index:1}.g-dialog-body{flex:1 1 auto;overflow-y:auto;padding:10px var(--_--side-padding)}.g-dialog-body_has-borders{border-block-end:1px solid var(--g-color-line-generic)}.g-dialog-body_has-borders,.g-dialog-divider{border-block-start:1px solid var(--g-color-line-generic)}.g-dialog-divider{margin:0 calc(var(--_--side-padding)*-1)}.g-dialog-footer{align-items:center;display:flex;padding:28px var(--_--side-padding)}.g-dialog-footer__bts-wrapper{display:flex;gap:10px}.g-dialog-footer__children{align-items:center;display:flex;flex-grow:1;height:100%}.g-dialog-footer__button{min-width:128px;position:relative}.g-dialog-footer__error{color:var(--g-color-text-danger);padding:10px}.g-dialog-header{align-items:center;color:var(--g-color-text-primary);display:flex;justify-content:flex-start;line-height:24px;padding-block:20px 10px;padding-inline:var(--_--side-padding) calc(var(--_--side-padding) + var(--_--close-button-space)*var(--g-flow-is-ltr) + var(--_--close-button-space)*var(--g-flow-is-rtl))}.g-dialog-header__caption{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height)}.g-dialog{--_--side-padding:32px;--_--close-button-space:0px;display:flex;flex-direction:column;position:relative;width:var(--g-dialog-width,var(--_--width))}.g-dialog_has-scroll{max-height:calc(100vh - var(--g-modal-margin, 20px)*2);overflow-y:auto}.g-dialog_size_s{--_--width:480px}.g-dialog_size_m{--_--width:720px}.g-dialog_size_l{--_--width:900px}.g-dialog_has-close{--_--close-button-space:24px}.g-modal{-webkit-overflow-scrolling:touch;-webkit-tap-highlight-color:rgba(0,0,0,0);background-color:var(--g-color-sfx-veil);display:none;inset:0;margin:-9999px 0 0 -9999px;overflow:auto;position:fixed;visibility:hidden;z-index:1000}.g-modal__content-aligner{align-items:center;display:inline-flex;justify-content:center;min-height:100%;min-width:100%}.g-modal__content-wrapper{margin:var(--g-modal-margin,20px);overflow-x:hidden}.g-modal__content,.g-modal__content-wrapper{border-radius:var(--g-modal-border-radius,5px)}.g-modal__content{background-color:var(--g-color-base-modal)}.g-modal__content_has-scroll{max-height:calc(100vh - var(--g-modal-margin, 20px)*2);overflow-y:auto}.g-modal,.g-modal__content{animation-fill-mode:forwards;animation-timing-function:ease-out;outline:none}.g-modal_exit_active,.g-modal_open{display:block;margin:0;visibility:visible}.g-modal_appear_active,.g-modal_enter_active{animation-duration:.15s;animation-name:g-modal-open}.g-modal_appear_active .g-modal__content,.g-modal_enter_active .g-modal__content{animation-duration:.15s;animation-name:g-modal-content-open}.g-modal_exit_active{animation-duration:.2s;animation-name:g-modal}@keyframes g-modal{0%{opacity:1}to{opacity:0}}@keyframes g-modal-open{0%{opacity:0}to{opacity:1}}@keyframes g-modal-content-open{0%{transform:scale(.75)}to{transform:scale(1)}}.tablet-icon{border:1px solid;border-radius:4px;display:flex;font-size:10px;height:16px;justify-content:center;text-transform:uppercase;width:23px}.tablet-icon__type{line-height:14px}.header{align-items:center;border-bottom:1px solid var(--g-color-line-generic);display:flex;flex:0 0 40px;justify-content:space-between;padding:0 20px 0 12px}.header__breadcrumbs-item{color:var(--g-color-text-secondary);display:flex;gap:3px}.header__breadcrumbs-item_link:hover{color:var(--g-color-text-complementary)}.header__breadcrumbs-item_active{color:var(--g-color-text-primary)}.header__breadcrumbs-icon{align-items:center;display:flex}.g-divider{--_--content-gap:8px;--_--size:1px}.g-divider:not(:empty){align-items:center;border:none;display:flex}.g-divider:not(:empty):after,.g-divider:not(:empty):before{content:""}.g-divider:after,.g-divider:before{background:var(--g-divider-color,var(--g-color-line-generic));flex-grow:1}.g-divider_orientation_vertical{border-inline-start:1px solid var(--g-divider-color,var(--g-color-line-generic));flex-direction:column}.g-divider_orientation_vertical:after,.g-divider_orientation_vertical:before{width:var(--_--size)}.g-divider_orientation_vertical:before{margin-block-end:var(--_--content-gap)}.g-divider_orientation_vertical:after{margin-block-start:var(--_--content-gap)}.g-divider_orientation_horizontal{border-block-start:1px solid var(--g-divider-color,var(--g-color-line-generic))}.g-divider_orientation_horizontal:after,.g-divider_orientation_horizontal:before{height:var(--_--size)}.g-divider_orientation_horizontal:before{margin-inline-end:var(--_--content-gap)}.g-divider_orientation_horizontal:after{margin-inline-start:var(--_--content-gap)}.g-divider_align_end:after,.g-divider_align_start:before{display:none}.g-menu{background-color:var(--g-color-base-float);box-sizing:border-box;color:var(--g-color-text-primary);display:block;font-size:var(--g-text-body-1-font-size);list-style:none;margin:0;outline:none;overflow:hidden auto;padding:0;-webkit-user-select:none;user-select:none}.g-menu__list-group-item+.g-menu__list-group-item,.g-menu__list-group-item+.g-menu__list-item,.g-menu__list-item+.g-menu__list-group-item{border-block-start:1px solid var(--g-color-line-generic)}.g-menu__item{-webkit-tap-highlight-color:rgba(0,0,0,0);align-items:center;color:var(--g-color-text-primary);display:flex;outline:none;text-decoration:none;touch-action:manipulation}.g-menu__item-icon{display:flex}.g-menu__item-icon-end{display:flex;margin-inline-end:0}.g-menu__item-content{flex-grow:1;min-width:0}.g-menu__item_interactive{cursor:pointer}.g-menu__item_interactive:focus-visible,.g-menu__item_interactive:hover,.g-menu__item_selected{background-color:var(--g-color-base-simple-hover)}.g-menu__item_disabled{color:var(--g-color-text-secondary);cursor:default;pointer-events:none}.g-menu__item_disabled:hover{background-color:initial}.g-menu__item_active{background-color:var(--g-color-base-selection);cursor:default}.g-menu__item_active:focus-visible,.g-menu__item_active:hover{background-color:var(--g-color-base-selection-hover)}.g-menu__item_theme_danger:not(.g-menu__item_disabled){color:var(--g-color-text-danger)}.g-menu__group-label{color:var(--g-color-text-hint);font-weight:var(--g-text-accent-font-weight)}.g-menu__group-list{list-style:none;margin:0;padding:0}.g-menu_size_s{line-height:24px;padding:3px 0}.g-menu_size_s .g-menu__group-label,.g-menu_size_s .g-menu__item{padding:0 10px}.g-menu_size_s .g-menu__item-icon{margin-inline-end:3px}.g-menu_size_s .g-menu__item-icon-end{margin-inline-start:3px}.g-menu_size_s .g-menu__list-group-item+.g-menu__list-group-item,.g-menu_size_s .g-menu__list-group-item+.g-menu__list-item,.g-menu_size_s .g-menu__list-item+.g-menu__list-group-item{margin-block-start:3px;padding-block-start:3px}.g-menu_size_m{line-height:24px;padding:4px 0}.g-menu_size_m .g-menu__group-label,.g-menu_size_m .g-menu__item{padding:0 13px}.g-menu_size_m .g-menu__item-icon{margin-inline-end:4px}.g-menu_size_m .g-menu__item-icon-end{margin-inline-start:4px}.g-menu_size_m .g-menu__list-group-item+.g-menu__list-group-item,.g-menu_size_m .g-menu__list-group-item+.g-menu__list-item,.g-menu_size_m .g-menu__list-item+.g-menu__list-group-item{margin-block-start:4px;padding-block-start:4px}.g-menu_size_l{line-height:28px;padding:5px 0}.g-menu_size_l .g-menu__group-label,.g-menu_size_l .g-menu__item{padding:0 15px}.g-menu_size_l .g-menu__item-icon{margin-inline-end:5px}.g-menu_size_l .g-menu__item-icon-end{margin-inline-start:5px}.g-menu_size_l .g-menu__list-group-item+.g-menu__list-group-item,.g-menu_size_l .g-menu__list-group-item+.g-menu__list-item,.g-menu_size_l .g-menu__list-item+.g-menu__list-group-item{margin-block-start:5px;padding-block-start:5px}.g-menu_size_xl{font-size:var(--g-text-body-2-font-size);line-height:36px;padding:6px 0}.g-menu_size_xl .g-menu__group-label,.g-menu_size_xl .g-menu__item{padding:0 15px}.g-menu_size_xl .g-menu__item-icon{margin-inline-end:6px}.g-menu_size_xl .g-menu__item-icon-end{margin-inline-start:6px}.g-menu_size_xl .g-menu__list-group-item:not(:first-child){margin-block-start:6px;padding-block-start:6px}.g-menu_size_xl .g-menu__list-group-item:not(:last-child){margin-block-end:6px;padding-block-end:6px}.g-dropdown-menu__switcher-wrapper{display:inline-block}.g-dropdown-menu__switcher-button{display:flex}.g-dropdown-menu__menu-item_separator{border-block-start:1px solid var(--g-color-line-generic-solid);margin:.5em 0;pointer-events:none}.g-dropdown-menu__sub-menu-arrow{inset-inline-end:-4px;position:relative}.g-dropdown-menu__sub-menu{position:relative}.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:after,.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:before{content:"";height:100%;inset-block-start:0;position:absolute;width:10px}.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:before{inset-inline-start:-10px}.g-dropdown-menu__sub-menu .g-dropdown-menu__menu:after{inset-inline-end:-10px}.g-breadcrumbs__inner{align-items:center;display:inline-flex;gap:4px;min-height:24px;overflow:hidden;width:100%}.g-breadcrumbs__switcher{background:none;border:none;color:inherit;color:var(--g-color-text-secondary);cursor:pointer;font-family:var(--g-text-body-font-family);font-size:inherit;font-weight:var(--g-text-body-font-weight);outline:none;padding:0}.g-breadcrumbs__switcher:focus-visible{outline:2px solid var(--g-color-line-focus)}.g-breadcrumbs__item,.g-breadcrumbs__switcher{display:inline-block;flex-shrink:1;overflow:hidden;text-overflow:ellipsis;white-space:nowrap}.g-breadcrumbs__item:focus-visible,.g-breadcrumbs__switcher:focus-visible{border-radius:var(--g-focus-border-radius);outline:2px solid var(--g-color-line-focus)}.g-breadcrumbs_calculated_no .g-breadcrumbs__item{overflow:visible}.g-breadcrumbs__divider{align-items:center;color:var(--g-color-text-secondary);display:flex}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item .g-menu__item{padding-inline-start:80px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(0) .g-menu__item{padding-inline-start:0!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:first-child .g-menu__item{padding-inline-start:8px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(2) .g-menu__item{padding-inline-start:16px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(3) .g-menu__item{padding-inline-start:24px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(4) .g-menu__item{padding-inline-start:32px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(5) .g-menu__item{padding-inline-start:40px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(6) .g-menu__item{padding-inline-start:48px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(7) .g-menu__item{padding-inline-start:56px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(8) .g-menu__item{padding-inline-start:64px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(9) .g-menu__item{padding-inline-start:72px!important}.g-breadcrumbs__popup_staircase .g-menu .g-menu__list-item:nth-child(10) .g-menu__item{padding-inline-start:80px!important}.link{color:var(--g-color-text-link);text-decoration:none}.link_external{margin-right:10px}.link:hover{color:var(--g-color-text-link-hover)}*{font-feature-settings:"tnum";box-sizing:border-box;font-variant-numeric:tabular-nums}.g-select-popup__tick-icon{box-sizing:initial}#root,body,html{box-sizing:border-box;height:100%;margin:0;overflow:auto;padding:0}:root{--g-color-base-yellow-light:#ffc70026;--g-color-base-yellow-medium:#ffdb4d66;--tenant-object-info-max-value-width:300px;--diagnostics-section-title-margin:20px;--diagnostics-section-margin:30px;--diagnostics-section-table-width:872px}.g-root{--ydb-data-table-color-hover:var(--g-color-base-simple-hover-solid);--ydb-color-status-grey:var(--g-color-base-neutral-heavy);--ydb-color-status-green:var(--g-color-base-positive-heavy);--ydb-color-status-yellow:var(--g-color-base-warning-heavy);--ydb-color-status-orange:var(--g-color-private-orange-500-solid);--ydb-color-status-red:var(--g-color-base-danger-heavy);--ydb-color-status-blue:var(--g-color-base-info-heavy);--ydb-color-status-black:var(--g-color-base-misc-heavy);--g-popover-max-width:500px}:is(#tab,.g-tabs-item_active .g-tabs-item__title){color:var(--g-color-text-primary)!important}:is(#tab,.g-tabs-item__title){color:var(--g-color-text-secondary)}.gn-aside-header__pane-container{height:100%}.gn-aside-header__content{display:flex;flex-direction:column;height:100%;overflow:auto;position:relative}.loader{align-items:center;display:flex;justify-content:center;left:50%;position:fixed;top:50%;z-index:99999999}.app{--data-table-row-height:40px;--data-table-cell-align:middle;--data-table-head-align:middle;display:flex;flex:1 1 auto;flex-direction:column;height:100%}.app .data-table{font-size:var(--g-text-body-2-font-size);line-height:var(--g-text-body-2-line-height)}.app .data-table__td,.app .data-table__th{border-left:unset;border-right:unset;border-top:unset;height:var(--data-table-row-height)}.app .data-table__th{font-weight:700}.app .data-table__table{border-collapse:initial;border-spacing:0}.app .data-table__box_sticky-head_moving .data-table__th{height:unset}.app__main{display:flex;flex:1 1 auto;flex-direction:column;overflow:auto}.error{color:var(--g-color-text-danger)}.g-root .data-table_highlight-rows .data-table__row:hover{background:var(--ydb-data-table-color-hover)}.g-table-column-setup__item{cursor:pointer!important;padding:0 8px 0 32px!important}.app_embedded{font-family:Rubik,sans-serif}.kv-navigation__internal-user{align-items:center;display:flex;justify-content:space-between;line-height:var(--g-text-body-2-line-height);margin-left:16px}.kv-navigation__user-info-wrapper{display:flex;flex-direction:column}.kv-navigation__ydb-internal-user-title{font-weight:500}.kv-navigation__ydb-user-wrapper{padding:10px;width:300px}.g-list{--_--item-padding:var(--g-list-item-padding,0);display:flex;flex:1 1 auto;flex-direction:column;outline:none;width:100%}.g-list__filter{flex:0 0 auto;margin-block-end:8px;padding:var(--_--item-padding)}.g-list__items{flex:1 1 auto}.g-list__empty-placeholder,.g-list__item{align-items:center;box-sizing:border-box;display:flex;overflow:hidden;padding:var(--_--item-padding);-webkit-user-select:none;user-select:none}.g-list__item_active{background:var(--g-color-base-simple-hover)}.g-list__item_selected{background:var(--g-color-base-selection)}.g-list__item_selected:hover{background:var(--g-color-base-selection-hover)}.g-list__item_sort-handle-align_right{flex-direction:row-reverse}.g-list__item_sort-handle-align_right .g-list__item-sort-icon{margin-inline:10px 0}.g-list__item_sortable[data-rbd-drag-handle-context-id]:active{cursor:grabbing}.g-list__item_dragging{background:var(--g-color-base-simple-hover-solid);z-index:100001}.g-list__empty-placeholder{box-sizing:border-box;color:var(--g-color-text-hint);min-height:36px;padding-block:8px}.g-list__item-content{align-items:center;display:flex;flex:1 1 auto;height:100%;overflow:hidden;text-overflow:ellipsis}.g-list__item-sort-icon{align-items:center;color:var(--g-color-text-hint);display:flex;flex:0 0 auto;margin-inline-end:4px;width:12px}.g-list__loading-indicator{align-items:center;display:flex;justify-content:center;width:100%}.extended-cluster{display:flex;height:100%}.extended-cluster__balancer{align-items:center;display:flex;flex-direction:row}.extended-cluster__clipboard-button{margin-left:5px}.g-toast{--_--item-gap:10px;--_--item-padding:16px;--_--background-color:var(--g-color-base-background);background-color:var(--_--background-color);border-radius:8px;box-shadow:0 0 15px var(--g-color-sfx-shadow);box-sizing:border-box;display:flex;font-size:var(--g-text-body-2-font-size);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));overflow:hidden;padding:var(--g-toaster-item-padding,var(--_--item-padding));position:relative;width:inherit;z-index:0}.g-toast_mobile{width:100%}.g-toast_theme_normal{--_--background-color:var(--g-color-base-float)}.g-toast_theme_info{--_--container-background-color:var(--g-color-base-info-light);--_--icon-color:var(--g-color-text-info-heavy)}.g-toast_theme_success{--_--container-background-color:var(--g-color-base-positive-light);--_--icon-color:var(--g-color-text-positive-heavy)}.g-toast_theme_warning{--_--container-background-color:var(--g-color-base-warning-light);--_--icon-color:var(--g-color-text-warning-heavy)}.g-toast_theme_danger{--_--container-background-color:var(--g-color-base-danger-light);--_--icon-color:var(--g-color-text-danger-heavy)}.g-toast_theme_utility{--_--container-background-color:var(--g-color-base-utility-light);--_--icon-color:var(--g-color-text-utility-heavy)}.g-toast__container{display:flex;flex:1 1 auto;flex-flow:column nowrap;min-height:var(--g-text-body-2-line-height);min-width:0}.g-toast__container:before{background-color:var(--_--container-background-color);content:"";height:100%;inset-block-start:0;inset-inline-start:0;pointer-events:none;position:absolute;width:100%;z-index:-1}.g-toast__icon-container{color:var(--_--icon-color);flex:0 0 auto;min-width:0;padding-block-start:2px;padding-inline-end:8px}.g-toast__title{font-family:var(--g-text-subheader-font-family);font-size:var(--g-text-subheader-3-font-size);font-weight:var(--g-text-subheader-font-weight);line-height:var(--g-text-subheader-3-line-height);margin:0;padding-inline-end:32px}.g-toast__content{margin-block-start:var(--g-spacing-2)}.g-toast__content_without-title{margin-block-start:0;padding-inline-end:32px}.g-toast__actions{margin-block-start:var(--g-spacing-3)}.g-toast__action{margin-inline-end:8px}.g-toast .g-toast__btn-close{inset-block-start:16px;inset-inline-end:16px;position:absolute}.g-toast-animation-mobile_enter{opacity:0;position:absolute}.g-toast-animation-mobile_enter_active{animation:g-toast-enter-mobile .6s ease-out forwards;position:relative}.g-toast-animation-mobile_exit_active{animation:g-toast-exit-mobile .6s ease-in forwards}@keyframes g-toast-enter-mobile{0%{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateY(10px)}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateY(10px)}to{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}}@keyframes g-toast-exit-mobile{0%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateY(10px)}to{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateY(10px)}}.g-toast-animation-desktop_enter{opacity:0;position:absolute}.g-toast-animation-desktop_enter_active{animation:g-toast-enter-desktop .6s ease-out forwards;position:relative}.g-toast-animation-desktop_exit_active{animation:g-toast-exit-desktop .6s ease-in forwards}@keyframes g-toast-enter-desktop{0%{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateX(calc(var(--g-flow-direction)*10px))}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(calc(var(--g-flow-direction)*10px))}to{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}}@keyframes g-toast-exit-desktop{0%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:1;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(0)}50%{height:var(--_--item-height);margin-block-end:var(--g-toaster-item-gap,var(--_--item-gap));opacity:0;padding:var(--g-toaster-item-padding,var(--_--item-padding));transform:translateX(calc(var(--g-flow-direction)*10px))}to{height:0;margin-block-end:0;opacity:0;padding:0;transform:translateX(calc(var(--g-flow-direction)*10px))}}.g-toaster{--_--width:312px;align-items:flex-end;display:flex;flex-direction:column;inset-block-end:0;inset-inline-end:10px;position:fixed;width:var(--g-toaster-width,var(--_--width));z-index:100000}.g-toaster_mobile{--_--width:calc(100% - 20px);inset-inline-start:50%;transform:translate(-50%)}.g-root{--g-text-header-font-weight:500;--g-text-subheader-font-weight:600;--g-text-display-font-weight:500;--g-text-accent-font-weight:500}.g-root_theme_light{--g-color-base-background:#fff;--g-color-base-brand:var(--g-color-private-blue-550-solid);--g-color-base-brand-hover:var(--g-color-private-blue-600-solid);--g-color-base-selection:var(--g-color-private-blue-100);--g-color-base-selection-hover:var(--g-color-private-blue-200);--g-color-line-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand:var(--g-color-private-blue-600-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-700-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-600-solid);--g-color-text-link-hover:var(--g-color-private-blue-800-solid);--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-1000-solid:#fff;--g-color-private-black-50:#0000000d;--g-color-private-black-70:#00000012;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-20-solid:#fafafa;--g-color-private-black-50-solid:#f2f2f2;--g-color-private-black-100-solid:#e5e5e5;--g-color-private-black-150-solid:#d9d9d9;--g-color-private-black-200-solid:#ccc;--g-color-private-black-250-solid:#bfbfbf;--g-color-private-black-300-solid:#b3b3b3;--g-color-private-black-350-solid:#a6a6a6;--g-color-private-black-400-solid:#999;--g-color-private-black-450-solid:#8c8c8c;--g-color-private-black-500-solid:grey;--g-color-private-black-550-solid:#737373;--g-color-private-black-600-solid:#666;--g-color-private-black-650-solid:#595959;--g-color-private-black-700-solid:#4c4c4c;--g-color-private-black-750-solid:#404040;--g-color-private-black-800-solid:#333;--g-color-private-black-850-solid:#262626;--g-color-private-black-900-solid:#1a1a1a;--g-color-private-black-950-solid:#0d0d0d;--g-color-private-black-1000-solid:#000;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#eef3ff;--g-color-private-blue-100-solid:#e5ecff;--g-color-private-blue-150-solid:#dce6ff;--g-color-private-blue-200-solid:#cbdaff;--g-color-private-blue-250-solid:#bacdff;--g-color-private-blue-300-solid:#a8c1ff;--g-color-private-blue-350-solid:#97b4ff;--g-color-private-blue-400-solid:#86a8ff;--g-color-private-blue-450-solid:#749bff;--g-color-private-blue-500-solid:#638fff;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#4e79eb;--g-color-private-blue-650-solid:#4a71d6;--g-color-private-blue-700-solid:#4768c2;--g-color-private-blue-750-solid:#4360ad;--g-color-private-blue-800-solid:#3f5799;--g-color-private-blue-850-solid:#3c4f85;--g-color-private-blue-900-solid:#384670;--g-color-private-blue-950-solid:#343d5c;--g-color-private-blue-1000-solid:#333952;--g-color-private-green-50:#3bc9351a;--g-color-private-green-100:#3bc93526;--g-color-private-green-150:#3bc93533;--g-color-private-green-200:#3bc9354d;--g-color-private-green-250:#3bc93566;--g-color-private-green-300:#3bc93580;--g-color-private-green-350:#3bc93599;--g-color-private-green-400:#3bc935b3;--g-color-private-green-450:#3bc935cc;--g-color-private-green-500:#3bc935e6;--g-color-private-green-50-solid:#ebfaeb;--g-color-private-green-100-solid:#e2f7e1;--g-color-private-green-150-solid:#d8f4d7;--g-color-private-green-200-solid:#c4efc2;--g-color-private-green-250-solid:#b1e9ae;--g-color-private-green-300-solid:#9de49a;--g-color-private-green-350-solid:#89df86;--g-color-private-green-400-solid:#76d972;--g-color-private-green-450-solid:#62d45d;--g-color-private-green-500-solid:#4fce49;--g-color-private-green-550-solid:#3bc935;--g-color-private-green-600-solid:#3ab935;--g-color-private-green-650-solid:#38aa35;--g-color-private-green-700-solid:#379a34;--g-color-private-green-750-solid:#358a34;--g-color-private-green-800-solid:#347b34;--g-color-private-green-850-solid:#336b34;--g-color-private-green-900-solid:#315b34;--g-color-private-green-950-solid:#304b33;--g-color-private-green-1000-solid:#2f4433;--g-color-private-yellow-50:#ffdb4d1a;--g-color-private-yellow-100:#ffdb4d26;--g-color-private-yellow-150:#ffdb4d33;--g-color-private-yellow-200:#ffdb4d4d;--g-color-private-yellow-250:#ffdb4d66;--g-color-private-yellow-300:#ffdb4d80;--g-color-private-yellow-350:#ffdb4d99;--g-color-private-yellow-400:#ffdb4db3;--g-color-private-yellow-450:#ffdb4dcc;--g-color-private-yellow-500:#ffdb4de6;--g-color-private-yellow-50-solid:#fffbed;--g-color-private-yellow-100-solid:#fffae4;--g-color-private-yellow-150-solid:#fff8db;--g-color-private-yellow-200-solid:#fff4ca;--g-color-private-yellow-250-solid:#fff1b8;--g-color-private-yellow-300-solid:#ffeda6;--g-color-private-yellow-350-solid:#ffe994;--g-color-private-yellow-400-solid:#ffe682;--g-color-private-yellow-450-solid:#ffe271;--g-color-private-yellow-500-solid:#ffdf5f;--g-color-private-yellow-550-solid:#ffdb4d;--g-color-private-yellow-600-solid:#eac94a;--g-color-private-yellow-650-solid:#d5b848;--g-color-private-yellow-700-solid:#c0a645;--g-color-private-yellow-750-solid:#ab9543;--g-color-private-yellow-800-solid:#968340;--g-color-private-yellow-850-solid:#81723d;--g-color-private-yellow-900-solid:#6c603b;--g-color-private-yellow-950-solid:#574f38;--g-color-private-yellow-1000-solid:#4d4637;--g-color-private-orange-50:#ff77001a;--g-color-private-orange-100:#ff770026;--g-color-private-orange-150:#f703;--g-color-private-orange-200:#ff77004d;--g-color-private-orange-250:#f706;--g-color-private-orange-300:#ff770080;--g-color-private-orange-350:#f709;--g-color-private-orange-400:#ff7700b3;--g-color-private-orange-450:#f70c;--g-color-private-orange-500:#ff7700e6;--g-color-private-orange-50-solid:#fff1e6;--g-color-private-orange-100-solid:#ffebd9;--g-color-private-orange-150-solid:#ffe4cc;--g-color-private-orange-200-solid:#ffd6b3;--g-color-private-orange-250-solid:#ffc999;--g-color-private-orange-300-solid:#ffbb80;--g-color-private-orange-350-solid:#ffad66;--g-color-private-orange-400-solid:#ffa04c;--g-color-private-orange-450-solid:#ff9233;--g-color-private-orange-500-solid:#ff851a;--g-color-private-orange-550-solid:#f70;--g-color-private-orange-600-solid:#ea7005;--g-color-private-orange-650-solid:#d5680a;--g-color-private-orange-700-solid:#c0600f;--g-color-private-orange-750-solid:#ab5914;--g-color-private-orange-800-solid:#965119;--g-color-private-orange-850-solid:#814a1f;--g-color-private-orange-900-solid:#6c4324;--g-color-private-orange-950-solid:#573b29;--g-color-private-orange-1000-solid:#4d372b;--g-color-private-red-50:#ff04001a;--g-color-private-red-100:#ff040026;--g-color-private-red-150:#ff040033;--g-color-private-red-200:#ff04004d;--g-color-private-red-250:#ff040066;--g-color-private-red-300:#ff040080;--g-color-private-red-350:#ff040099;--g-color-private-red-400:#ff0400b3;--g-color-private-red-450:#ff0400cc;--g-color-private-red-500:#ff0400e6;--g-color-private-red-50-solid:#ffe6e6;--g-color-private-red-100-solid:#ffd9d9;--g-color-private-red-150-solid:#ffcdcc;--g-color-private-red-200-solid:#ffb4b3;--g-color-private-red-250-solid:#ff9b99;--g-color-private-red-300-solid:#ff8280;--g-color-private-red-350-solid:#ff6966;--g-color-private-red-400-solid:#ff504c;--g-color-private-red-450-solid:#ff3733;--g-color-private-red-500-solid:#ff1e1a;--g-color-private-red-550-solid:#ff0400;--g-color-private-red-600-solid:#ea0805;--g-color-private-red-650-solid:#d50c0a;--g-color-private-red-700-solid:#c0100f;--g-color-private-red-750-solid:#ab1414;--g-color-private-red-800-solid:#961819;--g-color-private-red-850-solid:#811c1f;--g-color-private-red-900-solid:#6c2024;--g-color-private-red-950-solid:#572429;--g-color-private-red-1000-solid:#4d262b;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#f4eefa;--g-color-private-purple-100-solid:#eee5f7;--g-color-private-purple-150-solid:#e9dcf5;--g-color-private-purple-200-solid:#ddcbf0;--g-color-private-purple-250-solid:#d2baeb;--g-color-private-purple-300-solid:#c7a9e6;--g-color-private-purple-350-solid:#bc97e0;--g-color-private-purple-400-solid:#b186db;--g-color-private-purple-450-solid:#a575d6;--g-color-private-purple-500-solid:#9a63d1;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#854ebd;--g-color-private-purple-650-solid:#7b4aad;--g-color-private-purple-700-solid:#72479e;--g-color-private-purple-750-solid:#68438f;--g-color-private-purple-800-solid:#5e3f80;--g-color-private-purple-850-solid:#543b70;--g-color-private-purple-900-solid:#4a3761;--g-color-private-purple-950-solid:#413452;--g-color-private-purple-1000-solid:#3c324a;--g-color-private-cool-grey-50:#6b84991a;--g-color-private-cool-grey-100:#6b849926;--g-color-private-cool-grey-150:#6b849933;--g-color-private-cool-grey-200:#6b84994d;--g-color-private-cool-grey-250:#6b849966;--g-color-private-cool-grey-300:#6b849980;--g-color-private-cool-grey-350:#6b849999;--g-color-private-cool-grey-400:#6b8499b3;--g-color-private-cool-grey-450:#6b8499cc;--g-color-private-cool-grey-500:#6b8499e6;--g-color-private-cool-grey-50-solid:#f0f3f5;--g-color-private-cool-grey-100-solid:#e9edf0;--g-color-private-cool-grey-150-solid:#e1e6eb;--g-color-private-cool-grey-200-solid:#d3dae0;--g-color-private-cool-grey-250-solid:#c4ced6;--g-color-private-cool-grey-300-solid:#b5c1cc;--g-color-private-cool-grey-350-solid:#a6b5c2;--g-color-private-cool-grey-400-solid:#97a9b8;--g-color-private-cool-grey-450-solid:#899dad;--g-color-private-cool-grey-500-solid:#7a90a3;--g-color-private-cool-grey-550-solid:#6b8499;--g-color-private-cool-grey-600-solid:#657b8f;--g-color-private-cool-grey-650-solid:#5f7285;--g-color-private-cool-grey-700-solid:#586a7a;--g-color-private-cool-grey-750-solid:#526170;--g-color-private-cool-grey-800-solid:#4c5866;--g-color-private-cool-grey-850-solid:#464f5c;--g-color-private-cool-grey-900-solid:#404652;--g-color-private-cool-grey-950-solid:#393e47;--g-color-private-cool-grey-1000-solid:#363942}.g-root_theme_light-hc{--g-color-base-background:#fff;--g-color-base-brand:var(--g-color-private-blue-600-solid);--g-color-base-brand-hover:var(--g-color-private-blue-800-solid);--g-color-base-selection:var(--g-color-private-blue-250);--g-color-base-selection-hover:var(--g-color-private-blue-350);--g-color-line-brand:var(--g-color-private-blue-600-solid);--g-color-text-brand:var(--g-color-private-blue-650-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-900-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-650-solid);--g-color-text-link-hover:var(--g-color-private-blue-850-solid);--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-1000-solid:#fff;--g-color-private-black-50:#0000000d;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-50-solid:#f2f2f2;--g-color-private-black-100-solid:#e5e5e5;--g-color-private-black-150-solid:#d9d9d9;--g-color-private-black-200-solid:#ccc;--g-color-private-black-250-solid:#bfbfbf;--g-color-private-black-300-solid:#b3b3b3;--g-color-private-black-350-solid:#a6a6a6;--g-color-private-black-400-solid:#999;--g-color-private-black-450-solid:#8c8c8c;--g-color-private-black-500-solid:grey;--g-color-private-black-550-solid:#737373;--g-color-private-black-600-solid:#666;--g-color-private-black-650-solid:#595959;--g-color-private-black-700-solid:#4c4c4c;--g-color-private-black-750-solid:#404040;--g-color-private-black-800-solid:#333;--g-color-private-black-850-solid:#262626;--g-color-private-black-900-solid:#1a1a1a;--g-color-private-black-950-solid:#0d0d0d;--g-color-private-black-1000-solid:#000;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#eef3ff;--g-color-private-blue-100-solid:#e5ecff;--g-color-private-blue-150-solid:#dce6ff;--g-color-private-blue-200-solid:#cbdaff;--g-color-private-blue-250-solid:#bacdff;--g-color-private-blue-300-solid:#a8c1ff;--g-color-private-blue-350-solid:#97b4ff;--g-color-private-blue-400-solid:#86a8ff;--g-color-private-blue-450-solid:#749bff;--g-color-private-blue-500-solid:#638fff;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#4d79e9;--g-color-private-blue-650-solid:#486fd4;--g-color-private-blue-700-solid:#4366be;--g-color-private-blue-750-solid:#3f5ca8;--g-color-private-blue-800-solid:#3a5393;--g-color-private-blue-850-solid:#35497d;--g-color-private-blue-900-solid:#304067;--g-color-private-blue-950-solid:#2c3651;--g-color-private-blue-1000-solid:#293147;--g-color-private-green-50:#3bc9351a;--g-color-private-green-100:#3bc93526;--g-color-private-green-150:#3bc93533;--g-color-private-green-200:#3bc9354d;--g-color-private-green-250:#3bc93566;--g-color-private-green-300:#3bc93580;--g-color-private-green-350:#3bc93599;--g-color-private-green-400:#3bc935b3;--g-color-private-green-450:#3bc935cc;--g-color-private-green-500:#3bc935e6;--g-color-private-green-50-solid:#ebfaeb;--g-color-private-green-100-solid:#e2f7e1;--g-color-private-green-150-solid:#d8f4d7;--g-color-private-green-200-solid:#c4efc2;--g-color-private-green-250-solid:#b1e9ae;--g-color-private-green-300-solid:#9de49a;--g-color-private-green-350-solid:#89df86;--g-color-private-green-400-solid:#76d972;--g-color-private-green-450-solid:#62d45d;--g-color-private-green-500-solid:#4fce49;--g-color-private-green-550-solid:#3bc935;--g-color-private-green-600-solid:#38b833;--g-color-private-green-650-solid:#36a832;--g-color-private-green-700-solid:#339730;--g-color-private-green-750-solid:#31872f;--g-color-private-green-800-solid:#2f762e;--g-color-private-green-850-solid:#2c652c;--g-color-private-green-900-solid:#29552b;--g-color-private-green-950-solid:#274429;--g-color-private-green-1000-solid:#263c28;--g-color-private-yellow-50:#ffdb4d1a;--g-color-private-yellow-100:#ffdb4d26;--g-color-private-yellow-150:#ffdb4d33;--g-color-private-yellow-200:#ffdb4d4d;--g-color-private-yellow-250:#ffdb4d66;--g-color-private-yellow-300:#ffdb4d80;--g-color-private-yellow-350:#ffdb4d99;--g-color-private-yellow-400:#ffdb4db3;--g-color-private-yellow-450:#ffdb4dcc;--g-color-private-yellow-500:#ffdb4de6;--g-color-private-yellow-50-solid:#fffbed;--g-color-private-yellow-100-solid:#fffae4;--g-color-private-yellow-150-solid:#fff8db;--g-color-private-yellow-200-solid:#fff4ca;--g-color-private-yellow-250-solid:#fff1b8;--g-color-private-yellow-300-solid:#ffeda6;--g-color-private-yellow-350-solid:#ffe994;--g-color-private-yellow-400-solid:#ffe682;--g-color-private-yellow-450-solid:#ffe271;--g-color-private-yellow-500-solid:#ffdf5f;--g-color-private-yellow-550-solid:#ffdb4d;--g-color-private-yellow-600-solid:#e9c949;--g-color-private-yellow-650-solid:#d3b645;--g-color-private-yellow-700-solid:#bda441;--g-color-private-yellow-750-solid:#a7913d;--g-color-private-yellow-800-solid:#907f3a;--g-color-private-yellow-850-solid:#7a6d36;--g-color-private-yellow-900-solid:#645a32;--g-color-private-yellow-950-solid:#4e482e;--g-color-private-yellow-1000-solid:#433f2c;--g-color-private-orange-50:#ff77001a;--g-color-private-orange-100:#ff770026;--g-color-private-orange-150:#f703;--g-color-private-orange-200:#ff77004d;--g-color-private-orange-250:#f706;--g-color-private-orange-300:#ff770080;--g-color-private-orange-350:#f709;--g-color-private-orange-400:#ff7700b3;--g-color-private-orange-450:#f70c;--g-color-private-orange-500:#ff7700e6;--g-color-private-orange-50-solid:#fff1e6;--g-color-private-orange-100-solid:#ffebd9;--g-color-private-orange-150-solid:#ffe4cc;--g-color-private-orange-200-solid:#ffd6b3;--g-color-private-orange-250-solid:#ffc999;--g-color-private-orange-300-solid:#ffbb80;--g-color-private-orange-350-solid:#ffad66;--g-color-private-orange-400-solid:#ffa04c;--g-color-private-orange-450-solid:#ff9233;--g-color-private-orange-500-solid:#ff851a;--g-color-private-orange-550-solid:#f70;--g-color-private-orange-600-solid:#e96f04;--g-color-private-orange-650-solid:#d36608;--g-color-private-orange-700-solid:#bd5e0b;--g-color-private-orange-750-solid:#a7550f;--g-color-private-orange-800-solid:#904d13;--g-color-private-orange-850-solid:#7a4517;--g-color-private-orange-900-solid:#643c1b;--g-color-private-orange-950-solid:#4e341e;--g-color-private-orange-1000-solid:#433020;--g-color-private-red-50:#ff04001a;--g-color-private-red-100:#ff040026;--g-color-private-red-150:#ff040033;--g-color-private-red-200:#ff04004d;--g-color-private-red-250:#ff040066;--g-color-private-red-300:#ff040080;--g-color-private-red-350:#ff040099;--g-color-private-red-400:#ff0400b3;--g-color-private-red-450:#ff0400cc;--g-color-private-red-500:#ff0400e6;--g-color-private-red-50-solid:#ffe6e6;--g-color-private-red-100-solid:#ffd9d9;--g-color-private-red-150-solid:#ffcdcc;--g-color-private-red-200-solid:#ffb4b3;--g-color-private-red-250-solid:#ff9b99;--g-color-private-red-300-solid:#ff8280;--g-color-private-red-350-solid:#ff6966;--g-color-private-red-400-solid:#ff504c;--g-color-private-red-450-solid:#ff3733;--g-color-private-red-500-solid:#ff1e1a;--g-color-private-red-550-solid:#ff0400;--g-color-private-red-600-solid:#e90804;--g-color-private-red-650-solid:#d30b08;--g-color-private-red-700-solid:#bd0e0b;--g-color-private-red-750-solid:#a6110f;--g-color-private-red-800-solid:#901413;--g-color-private-red-850-solid:#7a1717;--g-color-private-red-900-solid:#641a1b;--g-color-private-red-950-solid:#4e1d1e;--g-color-private-red-1000-solid:#431e20;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#f4eefa;--g-color-private-purple-100-solid:#eee5f7;--g-color-private-purple-150-solid:#e9dcf5;--g-color-private-purple-200-solid:#ddcbf0;--g-color-private-purple-250-solid:#d2baeb;--g-color-private-purple-300-solid:#c7a9e6;--g-color-private-purple-350-solid:#bc97e0;--g-color-private-purple-400-solid:#b186db;--g-color-private-purple-450-solid:#a575d6;--g-color-private-purple-500-solid:#9a63d1;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#844dbb;--g-color-private-purple-650-solid:#7949ab;--g-color-private-purple-700-solid:#6e449a;--g-color-private-purple-750-solid:#633f8a;--g-color-private-purple-800-solid:#593b79;--g-color-private-purple-850-solid:#4e3668;--g-color-private-purple-900-solid:#433158;--g-color-private-purple-950-solid:#382c47;--g-color-private-purple-1000-solid:#322a3f;--g-color-private-cool-grey-50:#6b84991a;--g-color-private-cool-grey-100:#6b849926;--g-color-private-cool-grey-150:#6b849933;--g-color-private-cool-grey-200:#6b84994d;--g-color-private-cool-grey-250:#6b849966;--g-color-private-cool-grey-300:#6b849980;--g-color-private-cool-grey-350:#6b849999;--g-color-private-cool-grey-400:#6b8499b3;--g-color-private-cool-grey-450:#6b8499cc;--g-color-private-cool-grey-500:#6b8499e6;--g-color-private-cool-grey-50-solid:#f0f3f5;--g-color-private-cool-grey-100-solid:#e9edf0;--g-color-private-cool-grey-150-solid:#e1e6eb;--g-color-private-cool-grey-200-solid:#d3dae0;--g-color-private-cool-grey-250-solid:#c4ced6;--g-color-private-cool-grey-300-solid:#b5c1cc;--g-color-private-cool-grey-350-solid:#a6b5c2;--g-color-private-cool-grey-400-solid:#97a9b8;--g-color-private-cool-grey-450-solid:#899dad;--g-color-private-cool-grey-500-solid:#7a90a3;--g-color-private-cool-grey-550-solid:#6b8499;--g-color-private-cool-grey-600-solid:#647a8e;--g-color-private-cool-grey-650-solid:#5c7182;--g-color-private-cool-grey-700-solid:#556776;--g-color-private-cool-grey-750-solid:#4e5d6b;--g-color-private-cool-grey-800-solid:#465360;--g-color-private-cool-grey-850-solid:#3f4a54;--g-color-private-cool-grey-900-solid:#384049;--g-color-private-cool-grey-950-solid:#31363d;--g-color-private-cool-grey-1000-solid:#2d3237}.g-root_theme_dark{--g-color-base-background:#2d2c33;--g-color-base-brand:var(--g-color-private-blue-450-solid);--g-color-base-brand-hover:var(--g-color-private-blue-600-solid);--g-color-base-selection:var(--g-color-private-blue-150);--g-color-base-selection-hover:var(--g-color-private-blue-200);--g-color-line-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-600-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-550-solid);--g-color-text-link-hover:var(--g-color-private-blue-700-solid);--g-color-private-white-20:#ffffff05;--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-20-solid:#313037;--g-color-private-white-50-solid:#38373d;--g-color-private-white-70-solid:#3c3b41;--g-color-private-white-100-solid:#424147;--g-color-private-white-150-solid:#4d4c52;--g-color-private-white-200-solid:#57565c;--g-color-private-white-250-solid:#616166;--g-color-private-white-300-solid:#6c6b70;--g-color-private-white-350-solid:#77767a;--g-color-private-white-400-solid:#818085;--g-color-private-white-450-solid:#8b8b8f;--g-color-private-white-500-solid:#969699;--g-color-private-white-550-solid:#a0a0a3;--g-color-private-white-600-solid:#ababad;--g-color-private-white-650-solid:#b6b5b8;--g-color-private-white-700-solid:#c0c0c2;--g-color-private-white-750-solid:#cacacc;--g-color-private-white-800-solid:#d5d5d6;--g-color-private-white-850-solid:#dfdfe0;--g-color-private-white-900-solid:#eaeaeb;--g-color-private-white-950-solid:#f5f5f5;--g-color-private-white-1000-solid:#fff;--g-color-private-white-opaque-150:#4c4b51f2;--g-color-private-black-20:#00000005;--g-color-private-black-50:#0000000d;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-1000-solid:#000;--g-color-private-black-rock-850:#2d2c33;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#313547;--g-color-private-blue-100-solid:#333952;--g-color-private-blue-150-solid:#343d5c;--g-color-private-blue-200-solid:#384670;--g-color-private-blue-250-solid:#3c4e85;--g-color-private-blue-300-solid:#405799;--g-color-private-blue-350-solid:#4360ad;--g-color-private-blue-400-solid:#4768c2;--g-color-private-blue-450-solid:#4b71d6;--g-color-private-blue-500-solid:#4e79eb;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#638fff;--g-color-private-blue-650-solid:#759bff;--g-color-private-blue-700-solid:#86a8ff;--g-color-private-blue-750-solid:#97b4ff;--g-color-private-blue-800-solid:#a9c1ff;--g-color-private-blue-850-solid:#bacdff;--g-color-private-blue-900-solid:#cbdaff;--g-color-private-blue-950-solid:#dce6ff;--g-color-private-blue-1000-solid:#e5ecff;--g-color-private-green-50:#5bb5571a;--g-color-private-green-100:#5bb55726;--g-color-private-green-150:#5bb55733;--g-color-private-green-200:#5bb5574d;--g-color-private-green-250:#5bb55766;--g-color-private-green-300:#5bb55780;--g-color-private-green-350:#5bb55799;--g-color-private-green-400:#5bb557b3;--g-color-private-green-450:#5bb557cc;--g-color-private-green-500:#5bb557e6;--g-color-private-green-50-solid:#323a37;--g-color-private-green-100-solid:#344138;--g-color-private-green-150-solid:#36473a;--g-color-private-green-200-solid:#3b553e;--g-color-private-green-250-solid:#3f6341;--g-color-private-green-300-solid:#447145;--g-color-private-green-350-solid:#497e49;--g-color-private-green-400-solid:#4d8c4c;--g-color-private-green-450-solid:#529a50;--g-color-private-green-500-solid:#56a753;--g-color-private-green-550-solid:#5bb557;--g-color-private-green-600-solid:#6bbc68;--g-color-private-green-650-solid:#7cc479;--g-color-private-green-700-solid:#8ccb89;--g-color-private-green-750-solid:#9dd39a;--g-color-private-green-800-solid:#addaab;--g-color-private-green-850-solid:#bde1bc;--g-color-private-green-900-solid:#cee9cd;--g-color-private-green-950-solid:#def0dd;--g-color-private-green-1000-solid:#e6f4e6;--g-color-private-yellow-50:#ffcb001a;--g-color-private-yellow-100:#ffcb0026;--g-color-private-yellow-150:#ffcb0033;--g-color-private-yellow-200:#ffcb004d;--g-color-private-yellow-250:#ffcb0066;--g-color-private-yellow-300:#ffcb0080;--g-color-private-yellow-350:#ffcb0099;--g-color-private-yellow-400:#ffcb00b3;--g-color-private-yellow-450:#ffcb00cc;--g-color-private-yellow-500:#ffcb00e6;--g-color-private-yellow-50-solid:#423c2e;--g-color-private-yellow-100-solid:#4d442b;--g-color-private-yellow-150-solid:#574c29;--g-color-private-yellow-200-solid:#6c5c24;--g-color-private-yellow-250-solid:#816c1f;--g-color-private-yellow-300-solid:#967c19;--g-color-private-yellow-350-solid:#ab8c14;--g-color-private-yellow-400-solid:#c09b0f;--g-color-private-yellow-450-solid:#d5ab0a;--g-color-private-yellow-500-solid:#e9ba04;--g-color-private-yellow-550-solid:#ffcb00;--g-color-private-yellow-600-solid:#ffd01a;--g-color-private-yellow-650-solid:#ffd533;--g-color-private-yellow-700-solid:#ffdb4c;--g-color-private-yellow-750-solid:#ffe066;--g-color-private-yellow-800-solid:#ffe580;--g-color-private-yellow-850-solid:#ffea99;--g-color-private-yellow-900-solid:#ffefb3;--g-color-private-yellow-950-solid:#fff5cc;--g-color-private-yellow-1000-solid:#fff7d9;--g-color-private-orange-50:#c8630c1a;--g-color-private-orange-100:#c8630c26;--g-color-private-orange-150:#c8630c33;--g-color-private-orange-200:#c8630c4d;--g-color-private-orange-250:#c8630c66;--g-color-private-orange-300:#c8630c80;--g-color-private-orange-350:#c8630c99;--g-color-private-orange-400:#c8630cb3;--g-color-private-orange-450:#c8630ccc;--g-color-private-orange-500:#c8630ce6;--g-color-private-orange-50-solid:#3d322f;--g-color-private-orange-100-solid:#44342d;--g-color-private-orange-150-solid:#4c372b;--g-color-private-orange-200-solid:#5c3d27;--g-color-private-orange-250-solid:#6b4223;--g-color-private-orange-300-solid:#7b4720;--g-color-private-orange-350-solid:#8a4d1c;--g-color-private-orange-400-solid:#995218;--g-color-private-orange-450-solid:#a95814;--g-color-private-orange-500-solid:#b95e10;--g-color-private-orange-550-solid:#c8630c;--g-color-private-orange-600-solid:#ce7324;--g-color-private-orange-650-solid:#d3823d;--g-color-private-orange-700-solid:#d89255;--g-color-private-orange-750-solid:#dea16d;--g-color-private-orange-800-solid:#e3b185;--g-color-private-orange-850-solid:#e9c19e;--g-color-private-orange-900-solid:#efd0b6;--g-color-private-orange-950-solid:#f4e0ce;--g-color-private-orange-1000-solid:#f7e8db;--g-color-private-red-50:#e849451a;--g-color-private-red-100:#e8494526;--g-color-private-red-150:#e8494533;--g-color-private-red-200:#e849454d;--g-color-private-red-250:#e8494566;--g-color-private-red-300:#e8494580;--g-color-private-red-350:#e8494599;--g-color-private-red-400:#e84945b3;--g-color-private-red-450:#e84945cc;--g-color-private-red-500:#e84945e6;--g-color-private-red-50-solid:#402f35;--g-color-private-red-100-solid:#493036;--g-color-private-red-150-solid:#523237;--g-color-private-red-200-solid:#653539;--g-color-private-red-250-solid:#78383a;--g-color-private-red-300-solid:#8a3a3c;--g-color-private-red-350-solid:#9d3d3e;--g-color-private-red-400-solid:#b04040;--g-color-private-red-450-solid:#c34341;--g-color-private-red-500-solid:#d54644;--g-color-private-red-550-solid:#e84945;--g-color-private-red-600-solid:#ea5b58;--g-color-private-red-650-solid:#ec6d6b;--g-color-private-red-700-solid:#ef7f7d;--g-color-private-red-750-solid:#f19290;--g-color-private-red-800-solid:#f3a4a2;--g-color-private-red-850-solid:#f6b6b5;--g-color-private-red-900-solid:#f8c8c7;--g-color-private-red-950-solid:#fadbda;--g-color-private-red-1000-solid:#fce4e3;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#373042;--g-color-private-purple-100-solid:#3c324a;--g-color-private-purple-150-solid:#413452;--g-color-private-purple-200-solid:#4a3761;--g-color-private-purple-250-solid:#543b70;--g-color-private-purple-300-solid:#5e3f80;--g-color-private-purple-350-solid:#68438f;--g-color-private-purple-400-solid:#72479e;--g-color-private-purple-450-solid:#7b4aad;--g-color-private-purple-500-solid:#854ebd;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#9a63d1;--g-color-private-purple-650-solid:#a575d6;--g-color-private-purple-700-solid:#b186db;--g-color-private-purple-750-solid:#bc97e0;--g-color-private-purple-800-solid:#c7a9e6;--g-color-private-purple-850-solid:#d2baeb;--g-color-private-purple-900-solid:#ddcbf0;--g-color-private-purple-950-solid:#e9dcf5;--g-color-private-purple-1000-solid:#eee5f7;--g-color-private-cool-grey-50:#60809c1a;--g-color-private-cool-grey-100:#60809c26;--g-color-private-cool-grey-150:#60809c33;--g-color-private-cool-grey-200:#60809c4d;--g-color-private-cool-grey-250:#60809c66;--g-color-private-cool-grey-300:#60809c80;--g-color-private-cool-grey-350:#60809c99;--g-color-private-cool-grey-400:#60809cb3;--g-color-private-cool-grey-450:#60809ccc;--g-color-private-cool-grey-500:#60809ce6;--g-color-private-cool-grey-50-solid:#32343e;--g-color-private-cool-grey-100-solid:#353943;--g-color-private-cool-grey-150-solid:#373d48;--g-color-private-cool-grey-200-solid:#3c4552;--g-color-private-cool-grey-250-solid:#414e5d;--g-color-private-cool-grey-300-solid:#465667;--g-color-private-cool-grey-350-solid:#4c5e72;--g-color-private-cool-grey-400-solid:#51677d;--g-color-private-cool-grey-450-solid:#566f87;--g-color-private-cool-grey-500-solid:#5b7892;--g-color-private-cool-grey-550-solid:#60809c;--g-color-private-cool-grey-600-solid:#708da6;--g-color-private-cool-grey-650-solid:#8099b0;--g-color-private-cool-grey-700-solid:#90a6ba;--g-color-private-cool-grey-750-solid:#a0b3c3;--g-color-private-cool-grey-800-solid:#b0bfcd;--g-color-private-cool-grey-850-solid:#bfccd7;--g-color-private-cool-grey-900-solid:#cfd9e1;--g-color-private-cool-grey-950-solid:#dfe6eb;--g-color-private-cool-grey-1000-solid:#e7ecf0}.g-root_theme_dark-hc{--g-color-base-background:#222326;--g-color-base-brand:var(--g-color-private-blue-450-solid);--g-color-base-brand-hover:var(--g-color-private-blue-650-solid);--g-color-base-selection:var(--g-color-private-blue-250);--g-color-base-selection-hover:var(--g-color-private-blue-400);--g-color-line-brand:var(--g-color-private-blue-550-solid);--g-color-text-brand:var(--g-color-private-blue-650-solid);--g-color-text-brand-heavy:var(--g-color-private-blue-850-solid);--g-color-text-brand-contrast:var(--g-color-text-light-primary);--g-color-text-link:var(--g-color-private-blue-650-solid);--g-color-text-link-hover:var(--g-color-private-blue-800-solid);--g-color-private-white-50:#ffffff0d;--g-color-private-white-70:#ffffff12;--g-color-private-white-100:#ffffff1a;--g-color-private-white-150:#ffffff26;--g-color-private-white-200:#fff3;--g-color-private-white-250:#ffffff40;--g-color-private-white-300:#ffffff4d;--g-color-private-white-350:#ffffff59;--g-color-private-white-400:#fff6;--g-color-private-white-450:#ffffff73;--g-color-private-white-500:#ffffff80;--g-color-private-white-550:#ffffff8c;--g-color-private-white-600:#fff9;--g-color-private-white-650:#ffffffa6;--g-color-private-white-700:#ffffffb3;--g-color-private-white-750:#ffffffbf;--g-color-private-white-800:#fffc;--g-color-private-white-850:#ffffffd9;--g-color-private-white-900:#ffffffe6;--g-color-private-white-950:#fffffff2;--g-color-private-white-50-solid:#2d2e31;--g-color-private-white-100-solid:#38393c;--g-color-private-white-150-solid:#434447;--g-color-private-white-200-solid:#4e4f51;--g-color-private-white-250-solid:#595a5c;--g-color-private-white-300-solid:#646567;--g-color-private-white-350-solid:#6f7072;--g-color-private-white-400-solid:#7a7b7d;--g-color-private-white-450-solid:#858688;--g-color-private-white-500-solid:#909193;--g-color-private-white-550-solid:#9c9c9d;--g-color-private-white-600-solid:#a7a7a8;--g-color-private-white-650-solid:#b2b2b3;--g-color-private-white-700-solid:#bdbdbe;--g-color-private-white-750-solid:#c8c8c9;--g-color-private-white-800-solid:#d3d3d4;--g-color-private-white-850-solid:#dededf;--g-color-private-white-900-solid:#e9e9e9;--g-color-private-white-950-solid:#f4f4f4;--g-color-private-white-1000-solid:#fff;--g-color-private-white-opaque-150:#38393cf7;--g-color-private-black-20:#00000005;--g-color-private-black-50:#0000000d;--g-color-private-black-100:#0000001a;--g-color-private-black-150:#00000026;--g-color-private-black-200:#0003;--g-color-private-black-250:#00000040;--g-color-private-black-300:#0000004d;--g-color-private-black-350:#00000059;--g-color-private-black-400:#0006;--g-color-private-black-450:#00000073;--g-color-private-black-500:#00000080;--g-color-private-black-550:#0000008c;--g-color-private-black-600:#0009;--g-color-private-black-650:#000000a6;--g-color-private-black-700:#000000b3;--g-color-private-black-750:#000000bf;--g-color-private-black-800:#000c;--g-color-private-black-850:#000000d9;--g-color-private-black-900:#000000e6;--g-color-private-black-950:#000000f2;--g-color-private-black-1000-solid:#000;--g-color-private-black-rock-850:#2d2c33;--g-color-private-black-rock-950:#222326;--g-color-private-blue-50:#5282ff1a;--g-color-private-blue-100:#5282ff26;--g-color-private-blue-150:#5282ff33;--g-color-private-blue-200:#5282ff4d;--g-color-private-blue-250:#5282ff66;--g-color-private-blue-300:#5282ff80;--g-color-private-blue-350:#5282ff99;--g-color-private-blue-400:#5282ffb3;--g-color-private-blue-450:#5282ffcc;--g-color-private-blue-500:#5282ffe6;--g-color-private-blue-50-solid:#272d3c;--g-color-private-blue-100-solid:#293147;--g-color-private-blue-150-solid:#2c3651;--g-color-private-blue-200-solid:#304067;--g-color-private-blue-250-solid:#35497d;--g-color-private-blue-300-solid:#3a5393;--g-color-private-blue-350-solid:#3f5ca8;--g-color-private-blue-400-solid:#4466be;--g-color-private-blue-450-solid:#486fd4;--g-color-private-blue-500-solid:#4d79e9;--g-color-private-blue-550-solid:#5282ff;--g-color-private-blue-600-solid:#638fff;--g-color-private-blue-650-solid:#759bff;--g-color-private-blue-700-solid:#86a8ff;--g-color-private-blue-750-solid:#97b4ff;--g-color-private-blue-800-solid:#a9c1ff;--g-color-private-blue-850-solid:#bacdff;--g-color-private-blue-900-solid:#cbdaff;--g-color-private-blue-950-solid:#dce6ff;--g-color-private-blue-1000-solid:#e5ecff;--g-color-private-green-50:#5bb5571a;--g-color-private-green-100:#5bb55726;--g-color-private-green-150:#000;--g-color-private-green-200:#5bb5574d;--g-color-private-green-250:#5bb55766;--g-color-private-green-300:#5bb55780;--g-color-private-green-350:#5bb55799;--g-color-private-green-400:#5bb557b3;--g-color-private-green-450:#5bb557cc;--g-color-private-green-500:#5bb557e6;--g-color-private-green-50-solid:#28322b;--g-color-private-green-100-solid:#2b392d;--g-color-private-green-150-solid:#2d4030;--g-color-private-green-200-solid:#334f35;--g-color-private-green-250-solid:#395d3a;--g-color-private-green-300-solid:#3f6c3f;--g-color-private-green-350-solid:#447b43;--g-color-private-green-400-solid:#4a8948;--g-color-private-green-450-solid:#50984d;--g-color-private-green-500-solid:#55a652;--g-color-private-green-550-solid:#5bb557;--g-color-private-green-600-solid:#6bbc68;--g-color-private-green-650-solid:#7cc479;--g-color-private-green-700-solid:#8ccb89;--g-color-private-green-750-solid:#9dd39a;--g-color-private-green-800-solid:#addaab;--g-color-private-green-850-solid:#bde1bc;--g-color-private-green-900-solid:#cee9cd;--g-color-private-green-950-solid:#def0dd;--g-color-private-green-1000-solid:#e6f4e6;--g-color-private-yellow-50:#ffcb001a;--g-color-private-yellow-100:#ffcb0026;--g-color-private-yellow-150:#ffcb0033;--g-color-private-yellow-200:#ffcb004d;--g-color-private-yellow-250:#ffcb0066;--g-color-private-yellow-300:#ffcb0080;--g-color-private-yellow-350:#ffcb0099;--g-color-private-yellow-400:#ffcb00b3;--g-color-private-yellow-450:#ffcb00cc;--g-color-private-yellow-500:#ffcb00e6;--g-color-private-yellow-50-solid:#383422;--g-color-private-yellow-100-solid:#433c20;--g-color-private-yellow-150-solid:#4e451e;--g-color-private-yellow-200-solid:#64551b;--g-color-private-yellow-250-solid:#7a6617;--g-color-private-yellow-300-solid:#907713;--g-color-private-yellow-350-solid:#a7880f;--g-color-private-yellow-400-solid:#bd990b;--g-color-private-yellow-450-solid:#d3a908;--g-color-private-yellow-500-solid:#e9ba04;--g-color-private-yellow-550-solid:#ffcb00;--g-color-private-yellow-600-solid:#ffd01a;--g-color-private-yellow-650-solid:#ffd533;--g-color-private-yellow-700-solid:#ffdb4c;--g-color-private-yellow-750-solid:#ffe066;--g-color-private-yellow-800-solid:#ffe580;--g-color-private-yellow-850-solid:#ffea99;--g-color-private-yellow-900-solid:#ffefb3;--g-color-private-yellow-950-solid:#fff5cc;--g-color-private-yellow-1000-solid:#fff7d9;--g-color-private-orange-50:#c8630c1a;--g-color-private-orange-100:#c8630c26;--g-color-private-orange-150:#c8630c33;--g-color-private-orange-200:#c8630c4d;--g-color-private-orange-250:#c8630c66;--g-color-private-orange-300:#c8630c80;--g-color-private-orange-350:#c8630c99;--g-color-private-orange-400:#c8630cb3;--g-color-private-orange-450:#c8630ccc;--g-color-private-orange-500:#c8630ce6;--g-color-private-orange-50-solid:#332923;--g-color-private-orange-100-solid:#3b2d22;--g-color-private-orange-150-solid:#433021;--g-color-private-orange-200-solid:#54361e;--g-color-private-orange-250-solid:#643d1c;--g-color-private-orange-300-solid:#754319;--g-color-private-orange-350-solid:#864916;--g-color-private-orange-400-solid:#965014;--g-color-private-orange-450-solid:#a75611;--g-color-private-orange-500-solid:#b75d0f;--g-color-private-orange-550-solid:#c8630c;--g-color-private-orange-600-solid:#ce7324;--g-color-private-orange-650-solid:#d3823d;--g-color-private-orange-700-solid:#d89255;--g-color-private-orange-750-solid:#dea16d;--g-color-private-orange-800-solid:#e3b185;--g-color-private-orange-850-solid:#e9c19e;--g-color-private-orange-900-solid:#efd0b6;--g-color-private-orange-950-solid:#f4e0ce;--g-color-private-orange-1000-solid:#f7e8db;--g-color-private-red-50:#e849451a;--g-color-private-red-100:#e8494526;--g-color-private-red-150:#e8494533;--g-color-private-red-200:#e849454d;--g-color-private-red-250:#e8494566;--g-color-private-red-300:#e8494580;--g-color-private-red-350:#e8494599;--g-color-private-red-400:#e84945b3;--g-color-private-red-450:#e84945cc;--g-color-private-red-500:#e84945e6;--g-color-private-red-50-solid:#362729;--g-color-private-red-100-solid:#40292b;--g-color-private-red-150-solid:#4a2b2c;--g-color-private-red-200-solid:#5d2e2f;--g-color-private-red-250-solid:#713233;--g-color-private-red-300-solid:#853636;--g-color-private-red-350-solid:#993a39;--g-color-private-red-400-solid:#ac3d3c;--g-color-private-red-450-solid:#c0413f;--g-color-private-red-500-solid:#d44542;--g-color-private-red-550-solid:#e84945;--g-color-private-red-600-solid:#ea5b58;--g-color-private-red-650-solid:#ec6d6b;--g-color-private-red-700-solid:#ef7f7d;--g-color-private-red-750-solid:#f19290;--g-color-private-red-800-solid:#f3a4a2;--g-color-private-red-850-solid:#f6b6b5;--g-color-private-red-900-solid:#f8c8c7;--g-color-private-red-950-solid:#fadbda;--g-color-private-red-1000-solid:#fce4e3;--g-color-private-purple-50:#8f52cc1a;--g-color-private-purple-100:#8f52cc26;--g-color-private-purple-150:#8f52cc33;--g-color-private-purple-200:#8f52cc4d;--g-color-private-purple-250:#8f52cc66;--g-color-private-purple-300:#8f52cc80;--g-color-private-purple-350:#8f52cc99;--g-color-private-purple-400:#8f52ccb3;--g-color-private-purple-450:#8f52cccc;--g-color-private-purple-500:#8f52cce6;--g-color-private-purple-50-solid:#2d2837;--g-color-private-purple-100-solid:#322a3f;--g-color-private-purple-150-solid:#382c47;--g-color-private-purple-200-solid:#433158;--g-color-private-purple-250-solid:#4e3668;--g-color-private-purple-300-solid:#593b79;--g-color-private-purple-350-solid:#633f8a;--g-color-private-purple-400-solid:#6e449a;--g-color-private-purple-450-solid:#7949ab;--g-color-private-purple-500-solid:#844dbb;--g-color-private-purple-550-solid:#8f52cc;--g-color-private-purple-600-solid:#9a63d1;--g-color-private-purple-650-solid:#a575d6;--g-color-private-purple-700-solid:#b186db;--g-color-private-purple-750-solid:#bc97e0;--g-color-private-purple-800-solid:#c7a9e6;--g-color-private-purple-850-solid:#d2baeb;--g-color-private-purple-900-solid:#ddcbf0;--g-color-private-purple-950-solid:#e9dcf5;--g-color-private-purple-1000-solid:#eee5f7;--g-color-private-cool-grey-50:#60809c1a;--g-color-private-cool-grey-100:#60809c26;--g-color-private-cool-grey-150:#60809c33;--g-color-private-cool-grey-200:#60809c4d;--g-color-private-cool-grey-250:#60809c66;--g-color-private-cool-grey-300:#60809c80;--g-color-private-cool-grey-350:#60809c99;--g-color-private-cool-grey-400:#60809cb3;--g-color-private-cool-grey-450:#60809ccc;--g-color-private-cool-grey-500:#60809ce6;--g-color-private-cool-grey-50-solid:#282c32;--g-color-private-cool-grey-100-solid:#2b3138;--g-color-private-cool-grey-150-solid:#2e363e;--g-color-private-cool-grey-200-solid:#353f49;--g-color-private-cool-grey-250-solid:#3b4855;--g-color-private-cool-grey-300-solid:#415161;--g-color-private-cool-grey-350-solid:#475b6d;--g-color-private-cool-grey-400-solid:#4d6479;--g-color-private-cool-grey-450-solid:#546d84;--g-color-private-cool-grey-500-solid:#5a7790;--g-color-private-cool-grey-550-solid:#60809c;--g-color-private-cool-grey-600-solid:#708da6;--g-color-private-cool-grey-650-solid:#8099b0;--g-color-private-cool-grey-700-solid:#90a6ba;--g-color-private-cool-grey-750-solid:#a0b3c3;--g-color-private-cool-grey-800-solid:#b0bfcd;--g-color-private-cool-grey-850-solid:#bfccd7;--g-color-private-cool-grey-900-solid:#cfd9e1;--g-color-private-cool-grey-950-solid:#dfe6eb;--g-color-private-cool-grey-1000-solid:#e7ecf0}body{-webkit-font-smoothing:antialiased;-moz-osx-font-smoothing:grayscale;font-family:-apple-system,BlinkMacSystemFont,Segoe UI,Roboto,Oxygen,Ubuntu,Cantarell,Fira Sans,Droid Sans,Helvetica Neue,sans-serif;margin:0}code{font-family:source-code-pro,Menlo,Monaco,Consolas,Courier New,monospace} \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/10064.5442bcf6.chunk.js b/ydb/core/viewer/monitoring/static/js/10064.5442bcf6.chunk.js new file mode 100644 index 000000000000..6534bd636f38 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/10064.5442bcf6.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[10064],{10064:(e,t,n)=>{n.d(t,{default:()=>s});var a=n(70191);const s=n.n(a)()},70191:e=>{function t(e){!function(e){var t=e.util.clone(e.languages.javascript),n=/(?:\s|\/\/.*(?!.)|\/\*(?:[^*]|\*(?!\/))\*\/)/.source,a=/(?:\{(?:\{(?:\{[^{}]*\}|[^{}])*\}|[^{}])*\})/.source,s=/(?:\{*\.{3}(?:[^{}]|)*\})/.source;function g(e,t){return e=e.replace(//g,(function(){return n})).replace(//g,(function(){return a})).replace(//g,(function(){return s})),RegExp(e,t)}s=g(s).source,e.languages.jsx=e.languages.extend("markup",t),e.languages.jsx.tag.pattern=g(/<\/?(?:[\w.:-]+(?:+(?:[\w.:$-]+(?:=(?:"(?:\\[\s\S]|[^\\"])*"|'(?:\\[\s\S]|[^\\'])*'|[^\s{'"/>=]+|))?|))**\/?)?>/.source),e.languages.jsx.tag.inside.tag.pattern=/^<\/?[^\s>\/]*/,e.languages.jsx.tag.inside["attr-value"].pattern=/=(?!\{)(?:"(?:\\[\s\S]|[^\\"])*"|'(?:\\[\s\S]|[^\\'])*'|[^\s'">]+)/,e.languages.jsx.tag.inside.tag.inside["class-name"]=/^[A-Z]\w*(?:\.[A-Z]\w*)*$/,e.languages.jsx.tag.inside.comment=t.comment,e.languages.insertBefore("inside","attr-name",{spread:{pattern:g(//.source),inside:e.languages.jsx}},e.languages.jsx.tag),e.languages.insertBefore("inside","special-attr",{script:{pattern:g(/=/.source),alias:"language-javascript",inside:{"script-punctuation":{pattern:/^=(?=\{)/,alias:"punctuation"},rest:e.languages.jsx}}},e.languages.jsx.tag);var o=function(e){return e?"string"===typeof e?e:"string"===typeof e.content?e.content:e.content.map(o).join(""):""},c=function(t){for(var n=[],a=0;a0&&n[n.length-1].tagName===o(s.content[0].content[1])&&n.pop():"/>"===s.content[s.content.length-1].content||n.push({tagName:o(s.content[0].content[1]),openedBraces:0}):n.length>0&&"punctuation"===s.type&&"{"===s.content?n[n.length-1].openedBraces++:n.length>0&&n[n.length-1].openedBraces>0&&"punctuation"===s.type&&"}"===s.content?n[n.length-1].openedBraces--:g=!0),(g||"string"===typeof s)&&n.length>0&&0===n[n.length-1].openedBraces){var i=o(s);a0&&("string"===typeof t[a-1]||"plain-text"===t[a-1].type)&&(i=o(t[a-1])+i,t.splice(a-1,1),a--),t[a]=new e.Token("plain-text",i,null,i)}s.content&&"string"!==typeof s.content&&c(s.content)}};e.hooks.add("after-tokenize",(function(e){"jsx"!==e.language&&"tsx"!==e.language||c(e.tokens)}))}(e)}e.exports=t,t.displayName="jsx",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/10132.c1a19fa8.chunk.js b/ydb/core/viewer/monitoring/static/js/10132.c1a19fa8.chunk.js new file mode 100644 index 000000000000..6e1192daadf4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/10132.c1a19fa8.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[10132],{10132:(u,e,a)=>{a.d(e,{default:()=>t});var i=a(63581);const t=a.n(i)()},63581:(u,e,a)=>{var i=a(68266);function t(u){u.register(i),u.languages.purescript=u.languages.extend("haskell",{keyword:/\b(?:ado|case|class|data|derive|do|else|forall|if|in|infixl|infixr|instance|let|module|newtype|of|primitive|then|type|where)\b|\u2200/,"import-statement":{pattern:/(^[\t ]*)import\s+[A-Z][\w']*(?:\.[A-Z][\w']*)*(?:\s+as\s+[A-Z][\w']*(?:\.[A-Z][\w']*)*)?(?:\s+hiding\b)?/m,lookbehind:!0,inside:{keyword:/\b(?:as|hiding|import)\b/,punctuation:/\./}},builtin:/\b(?:absurd|add|ap|append|apply|between|bind|bottom|clamp|compare|comparing|compose|conj|const|degree|discard|disj|div|eq|flap|flip|gcd|identity|ifM|join|lcm|liftA1|liftM1|map|max|mempty|min|mod|mul|negate|not|notEq|one|otherwise|recip|show|sub|top|unit|unless|unlessM|void|when|whenM|zero)\b/,operator:[u.languages.haskell.operator[0],u.languages.haskell.operator[2],/[\xa2-\xa6\xa8\xa9\xac\xae-\xb1\xb4\xb8\xd7\xf7\u02c2-\u02c5\u02d2-\u02df\u02e5-\u02eb\u02ed\u02ef-\u02ff\u0375\u0384\u0385\u03f6\u0482\u058d-\u058f\u0606-\u0608\u060b\u060e\u060f\u06de\u06e9\u06fd\u06fe\u07f6\u07fe\u07ff\u09f2\u09f3\u09fa\u09fb\u0af1\u0b70\u0bf3-\u0bfa\u0c7f\u0d4f\u0d79\u0e3f\u0f01-\u0f03\u0f13\u0f15-\u0f17\u0f1a-\u0f1f\u0f34\u0f36\u0f38\u0fbe-\u0fc5\u0fc7-\u0fcc\u0fce\u0fcf\u0fd5-\u0fd8\u109e\u109f\u1390-\u1399\u166d\u17db\u1940\u19de-\u19ff\u1b61-\u1b6a\u1b74-\u1b7c\u1fbd\u1fbf-\u1fc1\u1fcd-\u1fcf\u1fdd-\u1fdf\u1fed-\u1fef\u1ffd\u1ffe\u2044\u2052\u207a-\u207c\u208a-\u208c\u20a0-\u20bf\u2100\u2101\u2103-\u2106\u2108\u2109\u2114\u2116-\u2118\u211e-\u2123\u2125\u2127\u2129\u212e\u213a\u213b\u2140-\u2144\u214a-\u214d\u214f\u218a\u218b\u2190-\u2307\u230c-\u2328\u232b-\u2426\u2440-\u244a\u249c-\u24e9\u2500-\u2767\u2794-\u27c4\u27c7-\u27e5\u27f0-\u2982\u2999-\u29d7\u29dc-\u29fb\u29fe-\u2b73\u2b76-\u2b95\u2b97-\u2bff\u2ce5-\u2cea\u2e50\u2e51\u2e80-\u2e99\u2e9b-\u2ef3\u2f00-\u2fd5\u2ff0-\u2ffb\u3004\u3012\u3013\u3020\u3036\u3037\u303e\u303f\u309b\u309c\u3190\u3191\u3196-\u319f\u31c0-\u31e3\u3200-\u321e\u322a-\u3247\u3250\u3260-\u327f\u328a-\u32b0\u32c0-\u33ff\u4dc0-\u4dff\ua490-\ua4c6\ua700-\ua716\ua720\ua721\ua789\ua78a\ua828-\ua82b\ua836-\ua839\uaa77-\uaa79\uab5b\uab6a\uab6b\ufb29\ufbb2-\ufbc1\ufdfc\ufdfd\ufe62\ufe64-\ufe66\ufe69\uff04\uff0b\uff1c-\uff1e\uff3e\uff40\uff5c\uff5e\uffe0-\uffe6\uffe8-\uffee\ufffc\ufffd]/]}),u.languages.purs=u.languages.purescript}u.exports=t,t.displayName="purescript",t.aliases=["purs"]},68266:u=>{function e(u){u.languages.haskell={comment:{pattern:/(^|[^-!#$%*+=?&@|~.:<>^\\\/])(?:--(?:(?=.)[^-!#$%*+=?&@|~.:<>^\\\/].*|$)|\{-[\s\S]*?-\})/m,lookbehind:!0},char:{pattern:/'(?:[^\\']|\\(?:[abfnrtv\\"'&]|\^[A-Z@[\]^_]|ACK|BEL|BS|CAN|CR|DC1|DC2|DC3|DC4|DEL|DLE|EM|ENQ|EOT|ESC|ETB|ETX|FF|FS|GS|HT|LF|NAK|NUL|RS|SI|SO|SOH|SP|STX|SUB|SYN|US|VT|\d+|o[0-7]+|x[0-9a-fA-F]+))'/,alias:"string"},string:{pattern:/"(?:[^\\"]|\\(?:\S|\s+\\))*"/,greedy:!0},keyword:/\b(?:case|class|data|deriving|do|else|if|in|infixl|infixr|instance|let|module|newtype|of|primitive|then|type|where)\b/,"import-statement":{pattern:/(^[\t ]*)import\s+(?:qualified\s+)?(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*(?:\s+as\s+(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*)?(?:\s+hiding\b)?/m,lookbehind:!0,inside:{keyword:/\b(?:as|hiding|import|qualified)\b/,punctuation:/\./}},builtin:/\b(?:abs|acos|acosh|all|and|any|appendFile|approxRational|asTypeOf|asin|asinh|atan|atan2|atanh|basicIORun|break|catch|ceiling|chr|compare|concat|concatMap|const|cos|cosh|curry|cycle|decodeFloat|denominator|digitToInt|div|divMod|drop|dropWhile|either|elem|encodeFloat|enumFrom|enumFromThen|enumFromThenTo|enumFromTo|error|even|exp|exponent|fail|filter|flip|floatDigits|floatRadix|floatRange|floor|fmap|foldl|foldl1|foldr|foldr1|fromDouble|fromEnum|fromInt|fromInteger|fromIntegral|fromRational|fst|gcd|getChar|getContents|getLine|group|head|id|inRange|index|init|intToDigit|interact|ioError|isAlpha|isAlphaNum|isAscii|isControl|isDenormalized|isDigit|isHexDigit|isIEEE|isInfinite|isLower|isNaN|isNegativeZero|isOctDigit|isPrint|isSpace|isUpper|iterate|last|lcm|length|lex|lexDigits|lexLitChar|lines|log|logBase|lookup|map|mapM|mapM_|max|maxBound|maximum|maybe|min|minBound|minimum|mod|negate|not|notElem|null|numerator|odd|or|ord|otherwise|pack|pi|pred|primExitWith|print|product|properFraction|putChar|putStr|putStrLn|quot|quotRem|range|rangeSize|read|readDec|readFile|readFloat|readHex|readIO|readInt|readList|readLitChar|readLn|readOct|readParen|readSigned|reads|readsPrec|realToFrac|recip|rem|repeat|replicate|return|reverse|round|scaleFloat|scanl|scanl1|scanr|scanr1|seq|sequence|sequence_|show|showChar|showInt|showList|showLitChar|showParen|showSigned|showString|shows|showsPrec|significand|signum|sin|sinh|snd|sort|span|splitAt|sqrt|subtract|succ|sum|tail|take|takeWhile|tan|tanh|threadToIOResult|toEnum|toInt|toInteger|toLower|toRational|toUpper|truncate|uncurry|undefined|unlines|until|unwords|unzip|unzip3|userError|words|writeFile|zip|zip3|zipWith|zipWith3)\b/,number:/\b(?:\d+(?:\.\d+)?(?:e[+-]?\d+)?|0o[0-7]+|0x[0-9a-f]+)\b/i,operator:[{pattern:/`(?:[A-Z][\w']*\.)*[_a-z][\w']*`/,greedy:!0},{pattern:/(\s)\.(?=\s)/,lookbehind:!0},/[-!#$%*+=?&@|~:<>^\\\/][-!#$%*+=?&@|~.:<>^\\\/]*|\.[-!#$%*+=?&@|~.:<>^\\\/]+/],hvariable:{pattern:/\b(?:[A-Z][\w']*\.)*[_a-z][\w']*/,inside:{punctuation:/\./}},constant:{pattern:/\b(?:[A-Z][\w']*\.)*[A-Z][\w']*/,inside:{punctuation:/\./}},punctuation:/[{}[\];(),.:]/},u.languages.hs=u.languages.haskell}u.exports=e,e.displayName="haskell",e.aliases=["hs"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/10242.86faa17f.chunk.js b/ydb/core/viewer/monitoring/static/js/10242.86faa17f.chunk.js new file mode 100644 index 000000000000..03b571af72e6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/10242.86faa17f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[10242],{3899:e=>{function a(e){!function(e){var a=e.languages.javadoclike={parameter:{pattern:/(^[\t ]*(?:\/{3}|\*|\/\*\*)\s*@(?:arg|arguments|param)\s+)\w+/m,lookbehind:!0},keyword:{pattern:/(^[\t ]*(?:\/{3}|\*|\/\*\*)\s*|\{)@[a-z][a-zA-Z-]+\b/m,lookbehind:!0},punctuation:/[{}]/};Object.defineProperty(a,"addSupport",{value:function(a,n){"string"===typeof a&&(a=[a]),a.forEach((function(a){!function(a,n){var s="doc-comment",t=e.languages[a];if(t){var i=t[s];if(!i){var r={};r[s]={pattern:/(^|[^\\])\/\*\*[^/][\s\S]*?(?:\*\/|$)/,lookbehind:!0,alias:"comment"},i=(t=e.languages.insertBefore(a,"comment",r))[s]}if(i instanceof RegExp&&(i=t[s]={pattern:i}),Array.isArray(i))for(var o=0,p=i.length;o{n.d(a,{default:()=>t});var s=n(81329);const t=n.n(s)()},16099:e=>{function a(e){!function(e){e.languages.typescript=e.languages.extend("javascript",{"class-name":{pattern:/(\b(?:class|extends|implements|instanceof|interface|new|type)\s+)(?!keyof\b)(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?:\s*<(?:[^<>]|<(?:[^<>]|<[^<>]*>)*>)*>)?/,lookbehind:!0,greedy:!0,inside:null},builtin:/\b(?:Array|Function|Promise|any|boolean|console|never|number|string|symbol|unknown)\b/}),e.languages.typescript.keyword.push(/\b(?:abstract|declare|is|keyof|readonly|require)\b/,/\b(?:asserts|infer|interface|module|namespace|type)\b(?=\s*(?:[{_$a-zA-Z\xA0-\uFFFF]|$))/,/\btype\b(?=\s*(?:[\{*]|$))/),delete e.languages.typescript.parameter,delete e.languages.typescript["literal-property"];var a=e.languages.extend("typescript",{});delete a["class-name"],e.languages.typescript["class-name"].inside=a,e.languages.insertBefore("typescript","function",{decorator:{pattern:/@[$\w\xA0-\uFFFF]+/,inside:{at:{pattern:/^@/,alias:"operator"},function:/^[\s\S]+/}},"generic-function":{pattern:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*\s*<(?:[^<>]|<(?:[^<>]|<[^<>]*>)*>)*>(?=\s*\()/,greedy:!0,inside:{function:/^#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*/,generic:{pattern:/<[\s\S]+/,alias:"class-name",inside:a}}}}),e.languages.ts=e.languages.typescript}(e)}e.exports=a,a.displayName="typescript",a.aliases=["ts"]},81329:(e,a,n)=>{var s=n(3899),t=n(16099);function i(e){e.register(s),e.register(t),function(e){var a=e.languages.javascript,n=/\{(?:[^{}]|\{(?:[^{}]|\{[^{}]*\})*\})+\}/.source,s="(@(?:arg|argument|param|property)\\s+(?:"+n+"\\s+)?)";e.languages.jsdoc=e.languages.extend("javadoclike",{parameter:{pattern:RegExp(s+/(?:(?!\s)[$\w\xA0-\uFFFF.])+(?=\s|$)/.source),lookbehind:!0,inside:{punctuation:/\./}}}),e.languages.insertBefore("jsdoc","keyword",{"optional-parameter":{pattern:RegExp(s+/\[(?:(?!\s)[$\w\xA0-\uFFFF.])+(?:=[^[\]]+)?\](?=\s|$)/.source),lookbehind:!0,inside:{parameter:{pattern:/(^\[)[$\w\xA0-\uFFFF\.]+/,lookbehind:!0,inside:{punctuation:/\./}},code:{pattern:/(=)[\s\S]*(?=\]$)/,lookbehind:!0,inside:a,alias:"language-javascript"},punctuation:/[=[\]]/}},"class-name":[{pattern:RegExp(/(@(?:augments|class|extends|interface|memberof!?|template|this|typedef)\s+(?:\s+)?)[A-Z]\w*(?:\.[A-Z]\w*)*/.source.replace(//g,(function(){return n}))),lookbehind:!0,inside:{punctuation:/\./}},{pattern:RegExp("(@[a-z]+\\s+)"+n),lookbehind:!0,inside:{string:a.string,number:a.number,boolean:a.boolean,keyword:e.languages.typescript.keyword,operator:/=>|\.\.\.|[&|?:*]/,punctuation:/[.,;=<>{}()[\]]/}}],example:{pattern:/(@example\s+(?!\s))(?:[^@\s]|\s+(?!\s))+?(?=\s*(?:\*\s*)?(?:@\w|\*\/))/,lookbehind:!0,inside:{code:{pattern:/^([\t ]*(?:\*\s*)?)\S.*$/m,lookbehind:!0,inside:a,alias:"language-javascript"}}}}),e.languages.javadoclike.addSupport("javascript",e.languages.jsdoc)}(e)}e.exports=i,i.displayName="jsdoc",i.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/10246.ee23b775.chunk.js b/ydb/core/viewer/monitoring/static/js/10246.ee23b775.chunk.js new file mode 100644 index 000000000000..6bb3e7de46ac --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/10246.ee23b775.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 10246.ee23b775.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[10246],{10246:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>o,language:()=>s});var o={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},s={tokenPostfix:".tcl",specialFunctions:["set","unset","rename","variable","proc","coroutine","foreach","incr","append","lappend","linsert","lreplace"],mainFunctions:["if","then","elseif","else","case","switch","while","for","break","continue","return","package","namespace","catch","exit","eval","expr","uplevel","upvar"],builtinFunctions:["file","info","concat","join","lindex","list","llength","lrange","lsearch","lsort","split","array","parray","binary","format","regexp","regsub","scan","string","subst","dict","cd","clock","exec","glob","pid","pwd","close","eof","fblocked","fconfigure","fcopy","fileevent","flush","gets","open","puts","read","seek","socket","tell","interp","after","auto_execok","auto_load","auto_mkindex","auto_reset","bgerror","error","global","history","load","source","time","trace","unknown","unset","update","vwait","winfo","wm","bind","event","pack","place","grid","font","bell","clipboard","destroy","focus","grab","lower","option","raise","selection","send","tk","tkwait","tk_bisque","tk_focusNext","tk_focusPrev","tk_focusFollowsMouse","tk_popup","tk_setPalette"],symbols:/[=>{n.d(e,{default:()=>r});var a=n(64916);const r=n.n(a)()},64916:t=>{function e(t){!function(t){var e={pattern:/(^[ \t]*| {2}|\t)#.*/m,lookbehind:!0,greedy:!0},n={pattern:/((?:^|[^\\])(?:\\{2})*)[$@&%]\{(?:[^{}\r\n]|\{[^{}\r\n]*\})*\}/,lookbehind:!0,inside:{punctuation:/^[$@&%]\{|\}$/}};function a(t,a){var r={"section-header":{pattern:/^ ?\*{3}.+?\*{3}/,alias:"keyword"}};for(var o in a)r[o]=a[o];return r.tag={pattern:/([\r\n](?: {2}|\t)[ \t]*)\[[-\w]+\]/,lookbehind:!0,inside:{punctuation:/\[|\]/}},r.variable=n,r.comment=e,{pattern:RegExp(/^ ?\*{3}[ \t]*[ \t]*\*{3}(?:.|[\r\n](?!\*{3}))*/.source.replace(//g,(function(){return t})),"im"),alias:"section",inside:r}}var r={pattern:/(\[Documentation\](?: {2}|\t)[ \t]*)(?![ \t]|#)(?:.|(?:\r\n?|\n)[ \t]*\.{3})+/,lookbehind:!0,alias:"string"},o={pattern:/([\r\n] ?)(?!#)(?:\S(?:[ \t]\S)*)+/,lookbehind:!0,alias:"function",inside:{variable:n}},i={pattern:/([\r\n](?: {2}|\t)[ \t]*)(?!\[|\.{3}|#)(?:\S(?:[ \t]\S)*)+/,lookbehind:!0,inside:{variable:n}};t.languages.robotframework={settings:a("Settings",{documentation:{pattern:/([\r\n] ?Documentation(?: {2}|\t)[ \t]*)(?![ \t]|#)(?:.|(?:\r\n?|\n)[ \t]*\.{3})+/,lookbehind:!0,alias:"string"},property:{pattern:/([\r\n] ?)(?!\.{3}|#)(?:\S(?:[ \t]\S)*)+/,lookbehind:!0}}),variables:a("Variables"),"test-cases":a("Test Cases",{"test-name":o,documentation:r,property:i}),keywords:a("Keywords",{"keyword-name":o,documentation:r,property:i}),tasks:a("Tasks",{"task-name":o,documentation:r,property:i}),comment:e},t.languages.robot=t.languages.robotframework}(t)}t.exports=e,e.displayName="robotframework",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1053.f976b474.chunk.js b/ydb/core/viewer/monitoring/static/js/1053.f976b474.chunk.js deleted file mode 100644 index bca86921c939..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1053.f976b474.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1053],{21053:function(a,n,t){a.exports=function(a){"use strict";function n(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var t=n(a),u={name:"se",weekdays:"sotnabeaivi_vuoss\xe1rga_ma\u014b\u014beb\xe1rga_gaskavahkku_duorastat_bearjadat_l\xe1vvardat".split("_"),months:"o\u0111\u0111ajagem\xe1nnu_guovvam\xe1nnu_njuk\u010dam\xe1nnu_cuo\u014bom\xe1nnu_miessem\xe1nnu_geassem\xe1nnu_suoidnem\xe1nnu_borgem\xe1nnu_\u010dak\u010dam\xe1nnu_golggotm\xe1nnu_sk\xe1bmam\xe1nnu_juovlam\xe1nnu".split("_"),weekStart:1,weekdaysShort:"sotn_vuos_ma\u014b_gask_duor_bear_l\xe1v".split("_"),monthsShort:"o\u0111\u0111j_guov_njuk_cuo_mies_geas_suoi_borg_\u010dak\u010d_golg_sk\xe1b_juov".split("_"),weekdaysMin:"s_v_m_g_d_b_L".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"MMMM D. [b.] YYYY",LLL:"MMMM D. [b.] YYYY [ti.] HH:mm",LLLL:"dddd, MMMM D. [b.] YYYY [ti.] HH:mm"},relativeTime:{future:"%s gea\u017ees",past:"ma\u014bit %s",s:"moadde sekunddat",m:"okta minuhta",mm:"%d minuhtat",h:"okta diimmu",hh:"%d diimmut",d:"okta beaivi",dd:"%d beaivvit",M:"okta m\xe1nnu",MM:"%d m\xe1nut",y:"okta jahki",yy:"%d jagit"}};return t.default.locale(u,null,!0),u}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1073.da2a8c8a.chunk.js b/ydb/core/viewer/monitoring/static/js/1073.da2a8c8a.chunk.js new file mode 100644 index 000000000000..5d04cdb6aece --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/1073.da2a8c8a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1073],{1073:(a,e,t)=>{t.d(e,{default:()=>b});var s=t(39750);const b=t.n(s)()},39750:a=>{function e(a){a.languages.asm6502={comment:/;.*/,directive:{pattern:/\.\w+(?= )/,alias:"property"},string:/(["'`])(?:\\.|(?!\1)[^\\\r\n])*\1/,"op-code":{pattern:/\b(?:ADC|AND|ASL|BCC|BCS|BEQ|BIT|BMI|BNE|BPL|BRK|BVC|BVS|CLC|CLD|CLI|CLV|CMP|CPX|CPY|DEC|DEX|DEY|EOR|INC|INX|INY|JMP|JSR|LDA|LDX|LDY|LSR|NOP|ORA|PHA|PHP|PLA|PLP|ROL|ROR|RTI|RTS|SBC|SEC|SED|SEI|STA|STX|STY|TAX|TAY|TSX|TXA|TXS|TYA|adc|and|asl|bcc|bcs|beq|bit|bmi|bne|bpl|brk|bvc|bvs|clc|cld|cli|clv|cmp|cpx|cpy|dec|dex|dey|eor|inc|inx|iny|jmp|jsr|lda|ldx|ldy|lsr|nop|ora|pha|php|pla|plp|rol|ror|rti|rts|sbc|sec|sed|sei|sta|stx|sty|tax|tay|tsx|txa|txs|tya)\b/,alias:"keyword"},"hex-number":{pattern:/#?\$[\da-f]{1,4}\b/i,alias:"number"},"binary-number":{pattern:/#?%[01]+\b/,alias:"number"},"decimal-number":{pattern:/#?\b\d+\b/,alias:"number"},register:{pattern:/\b[xya]\b/i,alias:"variable"},punctuation:/[(),:]/}}a.exports=e,e.displayName="asm6502",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/108.d2d9c180.chunk.js b/ydb/core/viewer/monitoring/static/js/108.d2d9c180.chunk.js deleted file mode 100644 index 4d473ba68ab4..000000000000 --- a/ydb/core/viewer/monitoring/static/js/108.d2d9c180.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[108],{80108:function(a,s,n){a.exports=function(a){"use strict";function s(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var n=s(a),_={name:"tzm-latn",weekdays:"asamas_aynas_asinas_akras_akwas_asimwas_asi\u1e0dyas".split("_"),months:"innayr_br\u02e4ayr\u02e4_mar\u02e4s\u02e4_ibrir_mayyw_ywnyw_ywlywz_\u0263w\u0161t_\u0161wtanbir_kt\u02e4wbr\u02e4_nwwanbir_dwjnbir".split("_"),weekStart:6,weekdaysShort:"asamas_aynas_asinas_akras_akwas_asimwas_asi\u1e0dyas".split("_"),monthsShort:"innayr_br\u02e4ayr\u02e4_mar\u02e4s\u02e4_ibrir_mayyw_ywnyw_ywlywz_\u0263w\u0161t_\u0161wtanbir_kt\u02e4wbr\u02e4_nwwanbir_dwjnbir".split("_"),weekdaysMin:"asamas_aynas_asinas_akras_akwas_asimwas_asi\u1e0dyas".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"dadkh s yan %s",past:"yan %s",s:"imik",m:"minu\u1e0d",mm:"%d minu\u1e0d",h:"sa\u025ba",hh:"%d tassa\u025bin",d:"ass",dd:"%d ossan",M:"ayowr",MM:"%d iyyirn",y:"asgas",yy:"%d isgasn"}};return n.default.locale(_,null,!0),_}(n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/10815.03541c68.chunk.js b/ydb/core/viewer/monitoring/static/js/10815.03541c68.chunk.js new file mode 100644 index 000000000000..d53276679dec --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/10815.03541c68.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[10815],{10815:(e,a,r)=>{r.d(a,{default:()=>t});var n=r(89080);const t=r.n(n)()},89080:e=>{function a(e){e.languages.r={comment:/#.*/,string:{pattern:/(['"])(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0},"percent-operator":{pattern:/%[^%\s]*%/,alias:"operator"},boolean:/\b(?:FALSE|TRUE)\b/,ellipsis:/\.\.(?:\.|\d+)/,number:[/\b(?:Inf|NaN)\b/,/(?:\b0x[\dA-Fa-f]+(?:\.\d*)?|\b\d+(?:\.\d*)?|\B\.\d+)(?:[EePp][+-]?\d+)?[iL]?/],keyword:/\b(?:NA|NA_character_|NA_complex_|NA_integer_|NA_real_|NULL|break|else|for|function|if|in|next|repeat|while)\b/,operator:/->?>?|<(?:=|=!]=?|::?|&&?|\|\|?|[+*\/^$@~]/,punctuation:/[(){}\[\],;]/}}e.exports=a,a.displayName="r",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1088.40c16ea2.chunk.js b/ydb/core/viewer/monitoring/static/js/1088.40c16ea2.chunk.js deleted file mode 100644 index 04c46aac52dc..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1088.40c16ea2.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1088],{61088:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),n={name:"bi",weekdays:"Sande_Mande_Tusde_Wenesde_Tosde_Fraede_Sarade".split("_"),months:"Januari_Februari_Maj_Eprel_Mei_Jun_Julae_Okis_Septemba_Oktoba_Novemba_Disemba".split("_"),weekStart:1,weekdaysShort:"San_Man_Tus_Wen_Tos_Frae_Sar".split("_"),monthsShort:"Jan_Feb_Maj_Epr_Mai_Jun_Jul_Oki_Sep_Okt_Nov_Dis".split("_"),weekdaysMin:"San_Ma_Tu_We_To_Fr_Sar".split("_"),ordinal:function(e){return e},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"lo %s",past:"%s bifo",s:"sam seken",m:"wan minit",mm:"%d minit",h:"wan haoa",hh:"%d haoa",d:"wan dei",dd:"%d dei",M:"wan manis",MM:"%d manis",y:"wan yia",yy:"%d yia"}};return _.default.locale(n,null,!0),n}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/10902.cd23357e.chunk.js b/ydb/core/viewer/monitoring/static/js/10902.cd23357e.chunk.js new file mode 100644 index 000000000000..c31d63834a06 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/10902.cd23357e.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 10902.cd23357e.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[10902],{10902:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>o});var i={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"}],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],autoCloseBefore:".,=}])>' \n\t",indentationRules:{increaseIndentPattern:new RegExp("^((?!\\/\\/).)*(\\{[^}\"'`]*|\\([^)\"'`]*|\\[[^\\]\"'`]*)$"),decreaseIndentPattern:new RegExp("^((?!.*?\\/\\*).*\\*/)?\\s*[\\}\\]].*$")}},o={defaultToken:"",tokenPostfix:".proto",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],symbols:/[=>/,{token:"@brackets",bracket:"@close",switchTo:"identifier"}]],field:[{include:"@whitespace"},["group",{cases:{"$S2==proto2":{token:"keyword",switchTo:"@groupDecl.$S2"}}}],[/(@identifier)(\s*)(=)/,["identifier","white",{token:"delimiter",next:"@pop"}]],[/@fullIdentifier|\./,{cases:{"@builtinTypes":"keyword","@default":"type.identifier"}}]],groupDecl:[{include:"@whitespace"},[/@identifier/,"identifier"],["=","operator"],[/{/,{token:"@brackets",bracket:"@open",switchTo:"@messageBody.$S2"}],{include:"@constant"}],type:[{include:"@whitespace"},[/@identifier/,"type.identifier","@pop"],[/./,"delimiter"]],identifier:[{include:"@whitespace"},[/@identifier/,"identifier","@pop"]],serviceDecl:[{include:"@whitespace"},[/@identifier/,"identifier"],[/{/,{token:"@brackets",bracket:"@open",switchTo:"@serviceBody.$S2"}]],serviceBody:[{include:"@whitespace"},{include:"@constant"},[/;/,"delimiter"],[/option\b/,"keyword","@option.$S2"],[/rpc\b/,"keyword","@rpc.$S2"],[/\[/,{token:"@brackets",bracket:"@open",next:"@options.$S2"}],[/}/,{token:"@brackets",bracket:"@close",next:"@pop"}]],rpc:[{include:"@whitespace"},[/@identifier/,"identifier"],[/\(/,{token:"@brackets",bracket:"@open",switchTo:"@request.$S2"}],[/{/,{token:"@brackets",bracket:"@open",next:"@methodOptions.$S2"}],[/;/,"delimiter","@pop"]],request:[{include:"@whitespace"},[/@messageType/,{cases:{stream:{token:"keyword",next:"@type.$S2"},"@default":"type.identifier"}}],[/\)/,{token:"@brackets",bracket:"@close",switchTo:"@returns.$S2"}]],returns:[{include:"@whitespace"},[/returns\b/,"keyword"],[/\(/,{token:"@brackets",bracket:"@open",switchTo:"@response.$S2"}]],response:[{include:"@whitespace"},[/@messageType/,{cases:{stream:{token:"keyword",next:"@type.$S2"},"@default":"type.identifier"}}],[/\)/,{token:"@brackets",bracket:"@close",switchTo:"@rpc.$S2"}]],methodOptions:[{include:"@whitespace"},{include:"@constant"},[/;/,"delimiter"],["option","keyword"],[/@optionName/,"annotation"],[/[()]/,"annotation.brackets"],[/=/,"operator"],[/}/,{token:"@brackets",bracket:"@close",next:"@pop"}]],comment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@push"],["\\*/","comment","@pop"],[/[\/*]/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",bracket:"@close",next:"@pop"}]],stringSingle:[[/[^\\']+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],constant:[["@boolLit","keyword.constant"],["@hexLit","number.hex"],["@octalLit","number.octal"],["@decimalLit","number"],["@floatLit","number.float"],[/("([^"\\]|\\.)*|'([^'\\]|\\.)*)$/,"string.invalid"],[/"/,{token:"string.quote",bracket:"@open",next:"@string"}],[/'/,{token:"string.quote",bracket:"@open",next:"@stringSingle"}],[/{/,{token:"@brackets",bracket:"@open",next:"@prototext"}],[/identifier/,"identifier"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],prototext:[{include:"@whitespace"},{include:"@constant"},[/@identifier/,"identifier"],[/[:;]/,"delimiter"],[/}/,{token:"@brackets",bracket:"@close",next:"@pop"}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/110.2c798565.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/10902.cd23357e.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/110.2c798565.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/10902.cd23357e.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/1094.b5bb2475.chunk.js b/ydb/core/viewer/monitoring/static/js/1094.b5bb2475.chunk.js deleted file mode 100644 index 17d61db7deff..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1094.b5bb2475.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 1094.b5bb2475.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1094],{51094:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>a,language:()=>c});var o=e=>`\\b${e}\\b`,i=e=>`(?!${e})`,r=o("[_a-zA-Z][_a-zA-Z0-9]*"),s=o("[_a-zA-Z-0-9]+"),a={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"/**",close:" */",notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],indentationRules:{decreaseIndentPattern:new RegExp("^((?!.*?/\\*).*\\*/)?\\s*[\\}\\]].*$"),increaseIndentPattern:new RegExp("^((?!//).)*(\\{([^}\"'`/]*|(\\t|[ ])*//.*)|\\([^)\"'`/]*|\\[[^\\]\"'`/]*)$"),unIndentedLinePattern:new RegExp("^(\\t|[ ])*[ ]\\*[^/]*\\*/\\s*$|^(\\t|[ ])*[ ]\\*/\\s*$|^(\\t|[ ])*[ ]\\*([ ]([^\\*]|\\*(?!/))*)?$")}},c={defaultToken:"",tokenPostfix:".tsp",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],symbols:/[=:;<>]+/,keywords:["import","model","scalar","namespace","op","interface","union","using","is","extends","enum","alias","return","void","if","else","projection","dec","extern","fn"],namedLiterals:["true","false","null","unknown","never"],escapes:'\\\\(u{[0-9A-Fa-f]+}|n|r|t|\\\\|"|\\${)',tokenizer:{root:[{include:"@expression"},{include:"@whitespace"}],stringVerbatim:[{regex:'(|"|"")[^"]',action:{token:"string"}},{regex:`"""${i('"')}`,action:{token:"string",next:"@pop"}}],stringLiteral:[{regex:"\\${",action:{token:"delimiter.bracket",next:"@bracketCounting"}},{regex:'[^\\\\"$]+',action:{token:"string"}},{regex:"@escapes",action:{token:"string.escape"}},{regex:"\\\\.",action:{token:"string.escape.invalid"}},{regex:'"',action:{token:"string",next:"@pop"}}],bracketCounting:[{regex:"{",action:{token:"delimiter.bracket",next:"@bracketCounting"}},{regex:"}",action:{token:"delimiter.bracket",next:"@pop"}},{include:"@expression"}],comment:[{regex:"[^\\*]+",action:{token:"comment"}},{regex:"\\*\\/",action:{token:"comment",next:"@pop"}},{regex:"[\\/*]",action:{token:"comment"}}],whitespace:[{regex:"[ \\t\\r\\n]"},{regex:"\\/\\*",action:{token:"comment",next:"@comment"}},{regex:"\\/\\/.*$",action:{token:"comment"}}],expression:[{regex:'"""',action:{token:"string",next:"@stringVerbatim"}},{regex:`"${i('""')}`,action:{token:"string",next:"@stringLiteral"}},{regex:"[0-9]+",action:{token:"number"}},{regex:r,action:{cases:{"@keywords":{token:"keyword"},"@namedLiterals":{token:"keyword"},"@default":{token:"identifier"}}}},{regex:`@${r}`,action:{token:"tag"}},{regex:`#${s}`,action:{token:"directive"}}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/110.2c798565.chunk.js b/ydb/core/viewer/monitoring/static/js/110.2c798565.chunk.js deleted file mode 100644 index 932267b328c8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/110.2c798565.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 110.2c798565.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[110],{60110:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>o,language:()=>s});var o={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"""',close:'"""',notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"""',close:'"""'},{open:'"',close:'"'}],folding:{offSide:!0}},s={defaultToken:"invalid",tokenPostfix:".gql",keywords:["null","true","false","query","mutation","subscription","extend","schema","directive","scalar","type","interface","union","enum","input","implements","fragment","on"],typeKeywords:["Int","Float","String","Boolean","ID"],directiveLocations:["SCHEMA","SCALAR","OBJECT","FIELD_DEFINITION","ARGUMENT_DEFINITION","INTERFACE","UNION","ENUM","ENUM_VALUE","INPUT_OBJECT","INPUT_FIELD_DEFINITION","QUERY","MUTATION","SUBSCRIPTION","FIELD","FRAGMENT_DEFINITION","FRAGMENT_SPREAD","INLINE_FRAGMENT","VARIABLE_DEFINITION"],operators:["=","!","?",":","&","|"],symbols:/[=!?:&|]+/,escapes:/\\(?:["\\\/bfnrt]|u[0-9A-Fa-f]{4})/,tokenizer:{root:[[/[a-z_][\w$]*/,{cases:{"@keywords":"keyword","@default":"key.identifier"}}],[/[$][\w$]*/,{cases:{"@keywords":"keyword","@default":"argument.identifier"}}],[/[A-Z][\w\$]*/,{cases:{"@typeKeywords":"keyword","@default":"type.identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/@symbols/,{cases:{"@operators":"operator","@default":""}}],[/@\s*[a-zA-Z_\$][\w\$]*/,{token:"annotation",log:"annotation token: $0"}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/"""/,{token:"string",next:"@mlstring",nextEmbedded:"markdown"}],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,{token:"string.quote",bracket:"@open",next:"@string"}]],mlstring:[[/[^"]+/,"string"],['"""',{token:"string",next:"@pop",nextEmbedded:"@pop"}]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,""],[/#.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/11192.56c4d6e0.chunk.js b/ydb/core/viewer/monitoring/static/js/11192.56c4d6e0.chunk.js new file mode 100644 index 000000000000..1332e3f751d7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/11192.56c4d6e0.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[11192],{11192:(e,a,r)=>{r.d(a,{default:()=>t});var b=r(52669);const t=r.n(b)()},52669:e=>{function a(e){e.languages.warpscript={comment:/#.*|\/\/.*|\/\*[\s\S]*?\*\//,string:{pattern:/"(?:[^"\\\r\n]|\\.)*"|'(?:[^'\\\r\n]|\\.)*'|<'(?:[^\\']|'(?!>)|\\.)*'>/,greedy:!0},variable:/\$\S+/,macro:{pattern:/@\S+/,alias:"property"},keyword:/\b(?:BREAK|CHECKMACRO|CONTINUE|CUDF|DEFINED|DEFINEDMACRO|EVAL|FAIL|FOR|FOREACH|FORSTEP|IFT|IFTE|MSGFAIL|NRETURN|RETHROW|RETURN|SWITCH|TRY|UDF|UNTIL|WHILE)\b/,number:/[+-]?\b(?:NaN|Infinity|\d+(?:\.\d*)?(?:[Ee][+-]?\d+)?|0x[\da-fA-F]+|0b[01]+)\b/,boolean:/\b(?:F|T|false|true)\b/,punctuation:/<%|%>|[{}[\]()]/,operator:/==|&&?|\|\|?|\*\*?|>>>?|<<|[<>!~]=?|[-/%^]|\+!?|\b(?:AND|NOT|OR)\b/}}e.exports=a,a.displayName="warpscript",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/11278.aab5c12c.chunk.js b/ydb/core/viewer/monitoring/static/js/11278.aab5c12c.chunk.js new file mode 100644 index 000000000000..ba4b946ea7a7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/11278.aab5c12c.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 11278.aab5c12c.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[11278],{11278:(e,o,t)=>{t.r(o),t.d(o,{conf:()=>n,language:()=>i});var n={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},i={defaultToken:"",tokenPostfix:".swift",identifier:/[a-zA-Z_][\w$]*/,attributes:["@GKInspectable","@IBAction","@IBDesignable","@IBInspectable","@IBOutlet","@IBSegueAction","@NSApplicationMain","@NSCopying","@NSManaged","@Sendable","@UIApplicationMain","@autoclosure","@actorIndependent","@asyncHandler","@available","@convention","@derivative","@differentiable","@discardableResult","@dynamicCallable","@dynamicMemberLookup","@escaping","@frozen","@globalActor","@inlinable","@inline","@main","@noDerivative","@nonobjc","@noreturn","@objc","@objcMembers","@preconcurrency","@propertyWrapper","@requires_stored_property_inits","@resultBuilder","@testable","@unchecked","@unknown","@usableFromInline","@warn_unqualified_access"],accessmodifiers:["open","public","internal","fileprivate","private"],keywords:["#available","#colorLiteral","#column","#dsohandle","#else","#elseif","#endif","#error","#file","#fileID","#fileLiteral","#filePath","#function","#if","#imageLiteral","#keyPath","#line","#selector","#sourceLocation","#warning","Any","Protocol","Self","Type","actor","as","assignment","associatedtype","associativity","async","await","break","case","catch","class","continue","convenience","default","defer","deinit","didSet","do","dynamic","dynamicType","else","enum","extension","fallthrough","false","fileprivate","final","for","func","get","guard","higherThan","if","import","in","indirect","infix","init","inout","internal","is","isolated","lazy","left","let","lowerThan","mutating","nil","none","nonisolated","nonmutating","open","operator","optional","override","postfix","precedence","precedencegroup","prefix","private","protocol","public","repeat","required","rethrows","return","right","safe","self","set","some","static","struct","subscript","super","switch","throw","throws","true","try","typealias","unowned","unsafe","var","weak","where","while","willSet","__consuming","__owned"],symbols:/[=(){}\[\].,:;@#\_&\-<>`?!+*\\\/]/,operatorstart:/[\/=\-+!*%<>&|^~?\u00A1-\u00A7\u00A9\u00AB\u00AC\u00AE\u00B0-\u00B1\u00B6\u00BB\u00BF\u00D7\u00F7\u2016-\u2017\u2020-\u2027\u2030-\u203E\u2041-\u2053\u2055-\u205E\u2190-\u23FF\u2500-\u2775\u2794-\u2BFF\u2E00-\u2E7F\u3001-\u3003\u3008-\u3030]/,operatorend:/[\u0300-\u036F\u1DC0-\u1DFF\u20D0-\u20FF\uFE00-\uFE0F\uFE20-\uFE2F\uE0100-\uE01EF]/,operators:/(@operatorstart)((@operatorstart)|(@operatorend))*/,escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[{include:"@whitespace"},{include:"@comment"},{include:"@attribute"},{include:"@literal"},{include:"@keyword"},{include:"@invokedmethod"},{include:"@symbol"}],whitespace:[[/\s+/,"white"],[/"""/,"string.quote","@endDblDocString"]],endDblDocString:[[/[^"]+/,"string"],[/\\"/,"string"],[/"""/,"string.quote","@popall"],[/"/,"string"]],symbol:[[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/[.]/,"delimiter"],[/@operators/,"operator"],[/@symbols/,"operator"]],comment:[[/\/\/\/.*$/,"comment.doc"],[/\/\*\*/,"comment.doc","@commentdocbody"],[/\/\/.*$/,"comment"],[/\/\*/,"comment","@commentbody"]],commentdocbody:[[/\/\*/,"comment","@commentbody"],[/\*\//,"comment.doc","@pop"],[/\:[a-zA-Z]+\:/,"comment.doc.param"],[/./,"comment.doc"]],commentbody:[[/\/\*/,"comment","@commentbody"],[/\*\//,"comment","@pop"],[/./,"comment"]],attribute:[[/@@@identifier/,{cases:{"@attributes":"keyword.control","@default":""}}]],literal:[[/"/,{token:"string.quote",next:"@stringlit"}],[/0[b]([01]_?)+/,"number.binary"],[/0[o]([0-7]_?)+/,"number.octal"],[/0[x]([0-9a-fA-F]_?)+([pP][\-+](\d_?)+)?/,"number.hex"],[/(\d_?)*\.(\d_?)+([eE][\-+]?(\d_?)+)?/,"number.float"],[/(\d_?)+/,"number"]],stringlit:[[/\\\(/,{token:"operator",next:"@interpolatedexpression"}],[/@escapes/,"string"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",next:"@pop"}],[/./,"string"]],interpolatedexpression:[[/\(/,{token:"operator",next:"@interpolatedexpression"}],[/\)/,{token:"operator",next:"@pop"}],{include:"@literal"},{include:"@keyword"},{include:"@symbol"}],keyword:[[/`/,{token:"operator",next:"@escapedkeyword"}],[/@identifier/,{cases:{"@keywords":"keyword","[A-Z][a-zA-Z0-9$]*":"type.identifier","@default":"identifier"}}]],escapedkeyword:[[/`/,{token:"operator",next:"@pop"}],[/./,"identifier"]],invokedmethod:[[/([.])(@identifier)/,{cases:{$2:["delimeter","type.identifier"],"@default":""}}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1278.d5c24e15.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/11278.aab5c12c.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/1278.d5c24e15.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/11278.aab5c12c.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/11338.6bb2b16a.chunk.js b/ydb/core/viewer/monitoring/static/js/11338.6bb2b16a.chunk.js new file mode 100644 index 000000000000..c0120e8475fd --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/11338.6bb2b16a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[11338],{11338:(e,n,a)=>{a.d(n,{default:()=>s});var t=a(74293);const s=a.n(t)()},74293:(e,n,a)=>{var t=a(89343);function s(e){e.register(t),e.languages.bison=e.languages.extend("c",{}),e.languages.insertBefore("bison","comment",{bison:{pattern:/^(?:[^%]|%(?!%))*%%[\s\S]*?%%/,inside:{c:{pattern:/%\{[\s\S]*?%\}|\{(?:\{[^}]*\}|[^{}])*\}/,inside:{delimiter:{pattern:/^%?\{|%?\}$/,alias:"punctuation"},"bison-variable":{pattern:/[$@](?:<[^\s>]+>)?[\w$]+/,alias:"variable",inside:{punctuation:/<|>/}},rest:e.languages.c}},comment:e.languages.c.comment,string:e.languages.c.string,property:/\S+(?=:)/,keyword:/%\w+/,number:{pattern:/(^|[^@])\b(?:0x[\da-f]+|\d+)/i,lookbehind:!0},punctuation:/%[%?]|[|:;\[\]<>]/}}})}e.exports=s,s.displayName="bison",s.aliases=[]},89343:e=>{function n(e){e.languages.c=e.languages.extend("clike",{comment:{pattern:/\/\/(?:[^\r\n\\]|\\(?:\r\n?|\n|(?![\r\n])))*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"class-name":{pattern:/(\b(?:enum|struct)\s+(?:__attribute__\s*\(\([\s\S]*?\)\)\s*)?)\w+|\b[a-z]\w*_t\b/,lookbehind:!0},keyword:/\b(?:_Alignas|_Alignof|_Atomic|_Bool|_Complex|_Generic|_Imaginary|_Noreturn|_Static_assert|_Thread_local|__attribute__|asm|auto|break|case|char|const|continue|default|do|double|else|enum|extern|float|for|goto|if|inline|int|long|register|return|short|signed|sizeof|static|struct|switch|typedef|typeof|union|unsigned|void|volatile|while)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ful]{0,4}/i,operator:/>>=?|<<=?|->|([-+&|:])\1|[?:~]|[-+*/%&|^!=<>]=?/}),e.languages.insertBefore("c","string",{char:{pattern:/'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n]){0,32}'/,greedy:!0}}),e.languages.insertBefore("c","string",{macro:{pattern:/(^[\t ]*)#\s*[a-z](?:[^\r\n\\/]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{string:[{pattern:/^(#\s*include\s*)<[^>]+>/,lookbehind:!0},e.languages.c.string],char:e.languages.c.char,comment:e.languages.c.comment,"macro-name":[{pattern:/(^#\s*define\s+)\w+\b(?!\()/i,lookbehind:!0},{pattern:/(^#\s*define\s+)\w+\b(?=\()/i,lookbehind:!0,alias:"function"}],directive:{pattern:/^(#\s*)[a-z]+/,lookbehind:!0,alias:"keyword"},"directive-hash":/^#/,punctuation:/##|\\(?=[\r\n])/,expression:{pattern:/\S[\s\S]*/,inside:e.languages.c}}}}),e.languages.insertBefore("c","function",{constant:/\b(?:EOF|NULL|SEEK_CUR|SEEK_END|SEEK_SET|__DATE__|__FILE__|__LINE__|__TIMESTAMP__|__TIME__|__func__|stderr|stdin|stdout)\b/}),delete e.languages.c.boolean}e.exports=n,n.displayName="c",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1146.65a37bc6.chunk.js b/ydb/core/viewer/monitoring/static/js/1146.65a37bc6.chunk.js new file mode 100644 index 000000000000..073cfff1a6fc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/1146.65a37bc6.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1146],{1146:(t,e,a)=>{a.d(e,{default:()=>i});var n=a(8799);const i=a.n(n)()},8799:t=>{function e(t){!function(t){var e=["on","ignoring","group_right","group_left","by","without"],a=["sum","min","max","avg","group","stddev","stdvar","count","count_values","bottomk","topk","quantile"].concat(e,["offset"]);t.languages.promql={comment:{pattern:/(^[ \t]*)#.*/m,lookbehind:!0},"vector-match":{pattern:new RegExp("((?:"+e.join("|")+")\\s*)\\([^)]*\\)"),lookbehind:!0,inside:{"label-key":{pattern:/\b[^,]+\b/,alias:"attr-name"},punctuation:/[(),]/}},"context-labels":{pattern:/\{[^{}]*\}/,inside:{"label-key":{pattern:/\b[a-z_]\w*(?=\s*(?:=|![=~]))/,alias:"attr-name"},"label-value":{pattern:/(["'`])(?:\\[\s\S]|(?!\1)[^\\])*\1/,greedy:!0,alias:"attr-value"},punctuation:/\{|\}|=~?|![=~]|,/}},"context-range":[{pattern:/\[[\w\s:]+\]/,inside:{punctuation:/\[|\]|:/,"range-duration":{pattern:/\b(?:\d+(?:[smhdwy]|ms))+\b/i,alias:"number"}}},{pattern:/(\boffset\s+)\w+/,lookbehind:!0,inside:{"range-duration":{pattern:/\b(?:\d+(?:[smhdwy]|ms))+\b/i,alias:"number"}}}],keyword:new RegExp("\\b(?:"+a.join("|")+")\\b","i"),function:/\b[a-z_]\w*(?=\s*\()/i,number:/[-+]?(?:(?:\b\d+(?:\.\d+)?|\B\.\d+)(?:e[-+]?\d+)?\b|\b(?:0x[0-9a-f]+|nan|inf)\b)/i,operator:/[\^*/%+-]|==|!=|<=|<|>=|>|\b(?:and|or|unless)\b/i,punctuation:/[{};()`,.[\]]/}}(t)}t.exports=e,e.displayName="promql",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/118.112f7e2f.chunk.js b/ydb/core/viewer/monitoring/static/js/118.112f7e2f.chunk.js deleted file mode 100644 index 8eb8364bc6be..000000000000 --- a/ydb/core/viewer/monitoring/static/js/118.112f7e2f.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 118.112f7e2f.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[118],{90118:(e,t,n)=>{n.r(t),n.d(t,{TagAngleInterpolationBracket:()=>B,TagAngleInterpolationDollar:()=>D,TagAutoInterpolationBracket:()=>w,TagAutoInterpolationDollar:()=>v,TagBracketInterpolationBracket:()=>C,TagBracketInterpolationDollar:()=>E});var o,i,_=n(80781),r=Object.defineProperty,a=Object.getOwnPropertyDescriptor,s=Object.getOwnPropertyNames,u=Object.prototype.hasOwnProperty,d=(e,t,n,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of s(t))u.call(e,i)||i===n||r(e,i,{get:()=>t[i],enumerable:!(o=a(t,i))||o.enumerable});return e},c={};d(c,o=_,"default"),i&&d(i,o,"default");var l=["assign","flush","ftl","return","global","import","include","break","continue","local","nested","nt","setting","stop","t","lt","rt","fallback"],k=["attempt","autoesc","autoEsc","compress","comment","escape","noescape","function","if","list","items","sep","macro","noparse","noParse","noautoesc","noAutoEsc","outputformat","switch","visit","recurse"],p={close:">",id:"angle",open:"<"},g={close:"\\]",id:"bracket",open:"\\["},A={close:"[>\\]]",id:"auto",open:"[<\\[]"},m={close:"\\}",id:"dollar",open1:"\\$",open2:"\\{"},b={close:"\\]",id:"bracket",open1:"\\[",open2:"="};function f(e){return{brackets:[["<",">"],["[","]"],["(",")"],["{","}"]],comments:{blockComment:[`${e.open}--`,`--${e.close}`]},autoCloseBefore:"\n\r\t }]),.:;=",autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"}],folding:{markers:{start:new RegExp(`${e.open}#(?:${k.join("|")})([^/${e.close}]*(?!/)${e.close})[^${e.open}]*$`),end:new RegExp(`${e.open}/#(?:${k.join("|")})[\\r\\n\\t ]*>`)}},onEnterRules:[{beforeText:new RegExp(`${e.open}#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/${e.close}]*(?!/)${e.close})[^${e.open}]*$`),afterText:new RegExp(`^${e.open}/#([a-zA-Z_]+)[\\r\\n\\t ]*${e.close}$`),action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`${e.open}#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/${e.close}]*(?!/)${e.close})[^${e.open}]*$`),action:{indentAction:c.languages.IndentAction.Indent}}]}}function F(){return{brackets:[["<",">"],["[","]"],["(",")"],["{","}"]],autoCloseBefore:"\n\r\t }]),.:;=",autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"}],folding:{markers:{start:new RegExp(`[<\\[]#(?:${k.join("|")})([^/>\\]]*(?!/)[>\\]])[^<\\[]*$`),end:new RegExp(`[<\\[]/#(?:${k.join("|")})[\\r\\n\\t ]*>`)}},onEnterRules:[{beforeText:new RegExp(`[<\\[]#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/>\\]]*(?!/)[>\\]])[^[<\\[]]*$`),afterText:new RegExp("^[<\\[]/#([a-zA-Z_]+)[\\r\\n\\t ]*[>\\]]$"),action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`[<\\[]#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/>\\]]*(?!/)[>\\]])[^[<\\[]]*$`),action:{indentAction:c.languages.IndentAction.Indent}}]}}function x(e,t){const n=`_${e.id}_${t.id}`,o=e=>e.replace(/__id__/g,n),i=e=>{const t=e.source.replace(/__id__/g,n);return new RegExp(t,e.flags)};return{unicode:!0,includeLF:!1,start:o("default__id__"),ignoreCase:!1,defaultToken:"invalid",tokenPostfix:".freemarker2",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],[o("open__id__")]:new RegExp(e.open),[o("close__id__")]:new RegExp(e.close),[o("iOpen1__id__")]:new RegExp(t.open1),[o("iOpen2__id__")]:new RegExp(t.open2),[o("iClose__id__")]:new RegExp(t.close),[o("startTag__id__")]:i(/(@open__id__)(#)/),[o("endTag__id__")]:i(/(@open__id__)(\/#)/),[o("startOrEndTag__id__")]:i(/(@open__id__)(\/?#)/),[o("closeTag1__id__")]:i(/((?:@blank)*)(@close__id__)/),[o("closeTag2__id__")]:i(/((?:@blank)*\/?)(@close__id__)/),blank:/[ \t\n\r]/,keywords:["false","true","in","as","using"],directiveStartCloseTag1:/attempt|recover|sep|auto[eE]sc|no(?:autoe|AutoE)sc|compress|default|no[eE]scape|comment|no[pP]arse/,directiveStartCloseTag2:/else|break|continue|return|stop|flush|t|lt|rt|nt|nested|recurse|fallback|ftl/,directiveStartBlank:/if|else[iI]f|list|for[eE]ach|switch|case|assign|global|local|include|import|function|macro|transform|visit|stop|return|call|setting|output[fF]ormat|nested|recurse|escape|ftl|items/,directiveEndCloseTag1:/if|list|items|sep|recover|attempt|for[eE]ach|local|global|assign|function|macro|output[fF]ormat|auto[eE]sc|no(?:autoe|AutoE)sc|compress|transform|switch|escape|no[eE]scape/,escapedChar:/\\(?:[ntrfbgla\\'"\{=]|(?:x[0-9A-Fa-f]{1,4}))/,asciiDigit:/[0-9]/,integer:/[0-9]+/,nonEscapedIdStartChar:/[\$@-Z_a-z\u00AA\u00B5\u00BA\u00C0-\u00D6\u00D8-\u00F6\u00F8-\u1FFF\u2071\u207F\u2090-\u209C\u2102\u2107\u210A-\u2113\u2115\u2119-\u211D\u2124\u2126\u2128\u212A-\u212D\u212F-\u2139\u213C-\u213F\u2145-\u2149\u214E\u2183-\u2184\u2C00-\u2C2E\u2C30-\u2C5E\u2C60-\u2CE4\u2CEB-\u2CEE\u2CF2-\u2CF3\u2D00-\u2D25\u2D27\u2D2D\u2D30-\u2D67\u2D6F\u2D80-\u2D96\u2DA0-\u2DA6\u2DA8-\u2DAE\u2DB0-\u2DB6\u2DB8-\u2DBE\u2DC0-\u2DC6\u2DC8-\u2DCE\u2DD0-\u2DD6\u2DD8-\u2DDE\u2E2F\u3005-\u3006\u3031-\u3035\u303B-\u303C\u3040-\u318F\u31A0-\u31BA\u31F0-\u31FF\u3300-\u337F\u3400-\u4DB5\u4E00-\uA48C\uA4D0-\uA4FD\uA500-\uA60C\uA610-\uA62B\uA640-\uA66E\uA67F-\uA697\uA6A0-\uA6E5\uA717-\uA71F\uA722-\uA788\uA78B-\uA78E\uA790-\uA793\uA7A0-\uA7AA\uA7F8-\uA801\uA803-\uA805\uA807-\uA80A\uA80C-\uA822\uA840-\uA873\uA882-\uA8B3\uA8D0-\uA8D9\uA8F2-\uA8F7\uA8FB\uA900-\uA925\uA930-\uA946\uA960-\uA97C\uA984-\uA9B2\uA9CF-\uA9D9\uAA00-\uAA28\uAA40-\uAA42\uAA44-\uAA4B\uAA50-\uAA59\uAA60-\uAA76\uAA7A\uAA80-\uAAAF\uAAB1\uAAB5-\uAAB6\uAAB9-\uAABD\uAAC0\uAAC2\uAADB-\uAADD\uAAE0-\uAAEA\uAAF2-\uAAF4\uAB01-\uAB06\uAB09-\uAB0E\uAB11-\uAB16\uAB20-\uAB26\uAB28-\uAB2E\uABC0-\uABE2\uABF0-\uABF9\uAC00-\uD7A3\uD7B0-\uD7C6\uD7CB-\uD7FB\uF900-\uFB06\uFB13-\uFB17\uFB1D\uFB1F-\uFB28\uFB2A-\uFB36\uFB38-\uFB3C\uFB3E\uFB40-\uFB41\uFB43-\uFB44\uFB46-\uFBB1\uFBD3-\uFD3D\uFD50-\uFD8F\uFD92-\uFDC7\uFDF0-\uFDFB\uFE70-\uFE74\uFE76-\uFEFC\uFF10-\uFF19\uFF21-\uFF3A\uFF41-\uFF5A\uFF66-\uFFBE\uFFC2-\uFFC7\uFFCA-\uFFCF\uFFD2-\uFFD7\uFFDA-\uFFDC]/,escapedIdChar:/\\[\-\.:#]/,idStartChar:/(?:@nonEscapedIdStartChar)|(?:@escapedIdChar)/,id:/(?:@idStartChar)(?:(?:@idStartChar)|(?:@asciiDigit))*/,specialHashKeys:/\*\*|\*|false|true|in|as|using/,namedSymbols:/<=|>=|\\lte|\\lt|<|\\gte|\\gt|>|&&|\\and|->|->|==|!=|\+=|-=|\*=|\/=|%=|\+\+|--|<=|&&|\|\||:|\.\.\.|\.\.\*|\.\.<|\.\.!|\?\?|=|<|\+|-|\*|\/|%|\||\.\.|\?|!|&|\.|,|;/,arrows:["->","->"],delimiters:[";",":",",","."],stringOperators:["lte","lt","gte","gt"],noParseTags:["noparse","noParse","comment"],tokenizer:{[o("default__id__")]:[{include:o("@directive_token__id__")},{include:o("@interpolation_and_text_token__id__")}],[o("fmExpression__id__.directive")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@directive_end_token__id__")},{include:o("@expression_token__id__")}],[o("fmExpression__id__.interpolation")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@expression_token__id__")},{include:o("@greater_operators_token__id__")}],[o("inParen__id__.plain")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@directive_end_token__id__")},{include:o("@expression_token__id__")}],[o("inParen__id__.gt")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@expression_token__id__")},{include:o("@greater_operators_token__id__")}],[o("noSpaceExpression__id__")]:[{include:o("@no_space_expression_end_token__id__")},{include:o("@directive_end_token__id__")},{include:o("@expression_token__id__")}],[o("unifiedCall__id__")]:[{include:o("@unified_call_token__id__")}],[o("singleString__id__")]:[{include:o("@string_single_token__id__")}],[o("doubleString__id__")]:[{include:o("@string_double_token__id__")}],[o("rawSingleString__id__")]:[{include:o("@string_single_raw_token__id__")}],[o("rawDoubleString__id__")]:[{include:o("@string_double_raw_token__id__")}],[o("expressionComment__id__")]:[{include:o("@expression_comment_token__id__")}],[o("noParse__id__")]:[{include:o("@no_parse_token__id__")}],[o("terseComment__id__")]:[{include:o("@terse_comment_token__id__")}],[o("directive_token__id__")]:[[i(/(?:@startTag__id__)(@directiveStartCloseTag1)(?:@closeTag1__id__)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{cases:{"@noParseTags":{token:"tag",next:o("@noParse__id__.$3")},"@default":{token:"tag"}}},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(?:@startTag__id__)(@directiveStartCloseTag2)(?:@closeTag2__id__)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(?:@startTag__id__)(@directiveStartBlank)(@blank)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"",next:o("@fmExpression__id__.directive")}]],[i(/(?:@endTag__id__)(@directiveEndCloseTag1)(?:@closeTag1__id__)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(@open__id__)(@)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive",next:o("@unifiedCall__id__")}]],[i(/(@open__id__)(\/@)((?:(?:@id)(?:\.(?:@id))*)?)(?:@closeTag1__id__)/),[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(@open__id__)#--/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:{token:"comment",next:o("@terseComment__id__")}],[i(/(?:@startOrEndTag__id__)([a-zA-Z_]+)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag.invalid",next:o("@fmExpression__id__.directive")}]]],[o("interpolation_and_text_token__id__")]:[[i(/(@iOpen1__id__)(@iOpen2__id__)/),[{token:"bracket"===t.id?"@brackets.interpolation":"delimiter.interpolation"},{token:"bracket"===t.id?"delimiter.interpolation":"@brackets.interpolation",next:o("@fmExpression__id__.interpolation")}]],[/[\$#<\[\{]|(?:@blank)+|[^\$<#\[\{\n\r\t ]+/,{token:"source"}]],[o("string_single_token__id__")]:[[/[^'\\]/,{token:"string"}],[/@escapedChar/,{token:"string.escape"}],[/'/,{token:"string",next:"@pop"}]],[o("string_double_token__id__")]:[[/[^"\\]/,{token:"string"}],[/@escapedChar/,{token:"string.escape"}],[/"/,{token:"string",next:"@pop"}]],[o("string_single_raw_token__id__")]:[[/[^']+/,{token:"string.raw"}],[/'/,{token:"string.raw",next:"@pop"}]],[o("string_double_raw_token__id__")]:[[/[^"]+/,{token:"string.raw"}],[/"/,{token:"string.raw",next:"@pop"}]],[o("expression_token__id__")]:[[/(r?)(['"])/,{cases:{"r'":[{token:"keyword"},{token:"string.raw",next:o("@rawSingleString__id__")}],'r"':[{token:"keyword"},{token:"string.raw",next:o("@rawDoubleString__id__")}],"'":[{token:"source"},{token:"string",next:o("@singleString__id__")}],'"':[{token:"source"},{token:"string",next:o("@doubleString__id__")}]}}],[/(?:@integer)(?:\.(?:@integer))?/,{cases:{"(?:@integer)":{token:"number"},"@default":{token:"number.float"}}}],[/(\.)(@blank*)(@specialHashKeys)/,[{token:"delimiter"},{token:""},{token:"identifier"}]],[/(?:@namedSymbols)/,{cases:{"@arrows":{token:"meta.arrow"},"@delimiters":{token:"delimiter"},"@default":{token:"operators"}}}],[/@id/,{cases:{"@keywords":{token:"keyword.$0"},"@stringOperators":{token:"operators"},"@default":{token:"identifier"}}}],[/[\[\]\(\)\{\}]/,{cases:{"\\[":{cases:{"$S2==gt":{token:"@brackets",next:o("@inParen__id__.gt")},"@default":{token:"@brackets",next:o("@inParen__id__.plain")}}},"\\]":{cases:{..."bracket"===t.id?{"$S2==interpolation":{token:"@brackets.interpolation",next:"@popall"}}:{},..."bracket"===e.id?{"$S2==directive":{token:"@brackets.directive",next:"@popall"}}:{},[o("$S1==inParen__id__")]:{token:"@brackets",next:"@pop"},"@default":{token:"@brackets"}}},"\\(":{token:"@brackets",next:o("@inParen__id__.gt")},"\\)":{cases:{[o("$S1==inParen__id__")]:{token:"@brackets",next:"@pop"},"@default":{token:"@brackets"}}},"\\{":{cases:{"$S2==gt":{token:"@brackets",next:o("@inParen__id__.gt")},"@default":{token:"@brackets",next:o("@inParen__id__.plain")}}},"\\}":{cases:{..."bracket"===t.id?{}:{"$S2==interpolation":{token:"@brackets.interpolation",next:"@popall"}},[o("$S1==inParen__id__")]:{token:"@brackets",next:"@pop"},"@default":{token:"@brackets"}}}}}],[/\$\{/,{token:"delimiter.invalid"}]],[o("blank_and_expression_comment_token__id__")]:[[/(?:@blank)+/,{token:""}],[/[<\[][#!]--/,{token:"comment",next:o("@expressionComment__id__")}]],[o("directive_end_token__id__")]:[[/>/,"bracket"===e.id?{token:"operators"}:{token:"@brackets.directive",next:"@popall"}],[i(/(\/)(@close__id__)/),[{token:"delimiter.directive"},{token:"@brackets.directive",next:"@popall"}]]],[o("greater_operators_token__id__")]:[[/>/,{token:"operators"}],[/>=/,{token:"operators"}]],[o("no_space_expression_end_token__id__")]:[[/(?:@blank)+/,{token:"",switchTo:o("@fmExpression__id__.directive")}]],[o("unified_call_token__id__")]:[[/(@id)((?:@blank)+)/,[{token:"tag"},{token:"",next:o("@fmExpression__id__.directive")}]],[i(/(@id)(\/?)(@close__id__)/),[{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive",next:"@popall"}]],[/./,{token:"@rematch",next:o("@noSpaceExpression__id__")}]],[o("no_parse_token__id__")]:[[i(/(@open__id__)(\/#?)([a-zA-Z]+)((?:@blank)*)(@close__id__)/),{cases:{"$S2==$3":[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:""},{token:"@brackets.directive",next:"@popall"}],"$S2==comment":[{token:"comment"},{token:"comment"},{token:"comment"},{token:"comment"},{token:"comment"}],"@default":[{token:"source"},{token:"source"},{token:"source"},{token:"source"},{token:"source"}]}}],[/[^<\[\-]+|[<\[\-]/,{cases:{"$S2==comment":{token:"comment"},"@default":{token:"source"}}}]],[o("expression_comment_token__id__")]:[[/--[>\]]/,{token:"comment",next:"@pop"}],[/[^\->\]]+|[>\]\-]/,{token:"comment"}]],[o("terse_comment_token__id__")]:[[i(/--(?:@close__id__)/),{token:"comment",next:"@popall"}],[/[^<\[\-]+|[<\[\-]/,{token:"comment"}]]}}}function $(e){const t=x(p,e),n=x(g,e),o=x(A,e);return{...t,...n,...o,unicode:!0,includeLF:!1,start:`default_auto_${e.id}`,ignoreCase:!1,defaultToken:"invalid",tokenPostfix:".freemarker2",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],tokenizer:{...t.tokenizer,...n.tokenizer,...o.tokenizer}}}var D={conf:f(p),language:x(p,m)},E={conf:f(g),language:x(g,m)},B={conf:f(p),language:x(p,b)},C={conf:f(g),language:x(g,b)},v={conf:F(),language:$(m)},w={conf:F(),language:$(b)}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/12776.d400f028.chunk.js b/ydb/core/viewer/monitoring/static/js/12776.d400f028.chunk.js new file mode 100644 index 000000000000..fd937d9bc340 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/12776.d400f028.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[12776],{12776:function(e,u,a){e.exports=function(e){"use strict";function u(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=u(e),_={name:"tet",weekdays:"Domingu_Segunda_Tersa_Kuarta_Kinta_Sesta_Sabadu".split("_"),months:"Janeiru_Fevereiru_Marsu_Abril_Maiu_Ju\xf1u_Jullu_Agustu_Setembru_Outubru_Novembru_Dezembru".split("_"),weekStart:1,weekdaysShort:"Dom_Seg_Ters_Kua_Kint_Sest_Sab".split("_"),monthsShort:"Jan_Fev_Mar_Abr_Mai_Jun_Jul_Ago_Set_Out_Nov_Dez".split("_"),weekdaysMin:"Do_Seg_Te_Ku_Ki_Ses_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"iha %s",past:"%s liuba",s:"minutu balun",m:"minutu ida",mm:"minutu %d",h:"oras ida",hh:"oras %d",d:"loron ida",dd:"loron %d",M:"fulan ida",MM:"fulan %d",y:"tinan ida",yy:"tinan %d"}};return a.default.locale(_,null,!0),_}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1278.d5c24e15.chunk.js b/ydb/core/viewer/monitoring/static/js/1278.d5c24e15.chunk.js deleted file mode 100644 index 23a5ca1b50ab..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1278.d5c24e15.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 1278.d5c24e15.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1278],{11278:(e,o,t)=>{t.r(o),t.d(o,{conf:()=>n,language:()=>i});var n={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},i={defaultToken:"",tokenPostfix:".swift",identifier:/[a-zA-Z_][\w$]*/,attributes:["@GKInspectable","@IBAction","@IBDesignable","@IBInspectable","@IBOutlet","@IBSegueAction","@NSApplicationMain","@NSCopying","@NSManaged","@Sendable","@UIApplicationMain","@autoclosure","@actorIndependent","@asyncHandler","@available","@convention","@derivative","@differentiable","@discardableResult","@dynamicCallable","@dynamicMemberLookup","@escaping","@frozen","@globalActor","@inlinable","@inline","@main","@noDerivative","@nonobjc","@noreturn","@objc","@objcMembers","@preconcurrency","@propertyWrapper","@requires_stored_property_inits","@resultBuilder","@testable","@unchecked","@unknown","@usableFromInline","@warn_unqualified_access"],accessmodifiers:["open","public","internal","fileprivate","private"],keywords:["#available","#colorLiteral","#column","#dsohandle","#else","#elseif","#endif","#error","#file","#fileID","#fileLiteral","#filePath","#function","#if","#imageLiteral","#keyPath","#line","#selector","#sourceLocation","#warning","Any","Protocol","Self","Type","actor","as","assignment","associatedtype","associativity","async","await","break","case","catch","class","continue","convenience","default","defer","deinit","didSet","do","dynamic","dynamicType","else","enum","extension","fallthrough","false","fileprivate","final","for","func","get","guard","higherThan","if","import","in","indirect","infix","init","inout","internal","is","isolated","lazy","left","let","lowerThan","mutating","nil","none","nonisolated","nonmutating","open","operator","optional","override","postfix","precedence","precedencegroup","prefix","private","protocol","public","repeat","required","rethrows","return","right","safe","self","set","some","static","struct","subscript","super","switch","throw","throws","true","try","typealias","unowned","unsafe","var","weak","where","while","willSet","__consuming","__owned"],symbols:/[=(){}\[\].,:;@#\_&\-<>`?!+*\\\/]/,operatorstart:/[\/=\-+!*%<>&|^~?\u00A1-\u00A7\u00A9\u00AB\u00AC\u00AE\u00B0-\u00B1\u00B6\u00BB\u00BF\u00D7\u00F7\u2016-\u2017\u2020-\u2027\u2030-\u203E\u2041-\u2053\u2055-\u205E\u2190-\u23FF\u2500-\u2775\u2794-\u2BFF\u2E00-\u2E7F\u3001-\u3003\u3008-\u3030]/,operatorend:/[\u0300-\u036F\u1DC0-\u1DFF\u20D0-\u20FF\uFE00-\uFE0F\uFE20-\uFE2F\uE0100-\uE01EF]/,operators:/(@operatorstart)((@operatorstart)|(@operatorend))*/,escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[{include:"@whitespace"},{include:"@comment"},{include:"@attribute"},{include:"@literal"},{include:"@keyword"},{include:"@invokedmethod"},{include:"@symbol"}],whitespace:[[/\s+/,"white"],[/"""/,"string.quote","@endDblDocString"]],endDblDocString:[[/[^"]+/,"string"],[/\\"/,"string"],[/"""/,"string.quote","@popall"],[/"/,"string"]],symbol:[[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/[.]/,"delimiter"],[/@operators/,"operator"],[/@symbols/,"operator"]],comment:[[/\/\/\/.*$/,"comment.doc"],[/\/\*\*/,"comment.doc","@commentdocbody"],[/\/\/.*$/,"comment"],[/\/\*/,"comment","@commentbody"]],commentdocbody:[[/\/\*/,"comment","@commentbody"],[/\*\//,"comment.doc","@pop"],[/\:[a-zA-Z]+\:/,"comment.doc.param"],[/./,"comment.doc"]],commentbody:[[/\/\*/,"comment","@commentbody"],[/\*\//,"comment","@pop"],[/./,"comment"]],attribute:[[/@@@identifier/,{cases:{"@attributes":"keyword.control","@default":""}}]],literal:[[/"/,{token:"string.quote",next:"@stringlit"}],[/0[b]([01]_?)+/,"number.binary"],[/0[o]([0-7]_?)+/,"number.octal"],[/0[x]([0-9a-fA-F]_?)+([pP][\-+](\d_?)+)?/,"number.hex"],[/(\d_?)*\.(\d_?)+([eE][\-+]?(\d_?)+)?/,"number.float"],[/(\d_?)+/,"number"]],stringlit:[[/\\\(/,{token:"operator",next:"@interpolatedexpression"}],[/@escapes/,"string"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",next:"@pop"}],[/./,"string"]],interpolatedexpression:[[/\(/,{token:"operator",next:"@interpolatedexpression"}],[/\)/,{token:"operator",next:"@pop"}],{include:"@literal"},{include:"@keyword"},{include:"@symbol"}],keyword:[[/`/,{token:"operator",next:"@escapedkeyword"}],[/@identifier/,{cases:{"@keywords":"keyword","[A-Z][a-zA-Z0-9$]*":"type.identifier","@default":"identifier"}}]],escapedkeyword:[[/`/,{token:"operator",next:"@pop"}],[/./,"identifier"]],invokedmethod:[[/([.])(@identifier)/,{cases:{$2:["delimeter","type.identifier"],"@default":""}}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1299.aaedb42e.chunk.js b/ydb/core/viewer/monitoring/static/js/1299.aaedb42e.chunk.js deleted file mode 100644 index f29e8dcb209a..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1299.aaedb42e.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1299],{81299:(e,l,c)=>{c.r(l),c.d(l,{ReactComponent:()=>m,default:()=>n});var t,a=c(59284);function h(){return h=Object.assign?Object.assign.bind():function(e){for(var l=1;l{o.r(t),o.d(t,{conf:()=>r,language:()=>n});var r={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["{","}"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*\\{\\$REGION(\\s\\'.*\\')?\\}"),end:new RegExp("^\\s*\\{\\$ENDREGION\\}")}}},n={defaultToken:"",tokenPostfix:".pascal",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["absolute","abstract","all","and_then","array","as","asm","attribute","begin","bindable","case","class","const","contains","default","div","else","end","except","exports","external","far","file","finalization","finally","forward","generic","goto","if","implements","import","in","index","inherited","initialization","interrupt","is","label","library","mod","module","name","near","not","object","of","on","only","operator","or_else","otherwise","override","package","packed","pow","private","program","protected","public","published","interface","implementation","qualified","read","record","resident","requires","resourcestring","restricted","segment","set","shl","shr","specialize","stored","strict","then","threadvar","to","try","type","unit","uses","var","view","virtual","dynamic","overload","reintroduce","with","write","xor","true","false","procedure","function","constructor","destructor","property","break","continue","exit","abort","while","do","for","raise","repeat","until"],typeKeywords:["boolean","double","byte","integer","shortint","char","longint","float","string"],operators:["=",">","<","<=",">=","<>",":",":=","and","or","+","-","*","/","@","&","^","%"],symbols:/[=><:@\^&|+\-*\/\^%]+/,tokenizer:{root:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\$[0-9a-fA-F]{1,16}/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'/,"string","@string"],[/'[^\\']'/,"string"],[/'/,"string.invalid"],[/\#\d+/,"string"]],comment:[[/[^\*\}]+/,"comment"],[/\}/,"comment","@pop"],[/[\{]/,"comment"]],string:[[/[^\\']+/,"string"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"],[/\{/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1321.401aa9b8.chunk.js b/ydb/core/viewer/monitoring/static/js/1321.401aa9b8.chunk.js deleted file mode 100644 index d56a273ab70e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1321.401aa9b8.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 1321.401aa9b8.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1321],{43702:(e,n,o)=>{o.r(n),o.d(n,{conf:()=>t,language:()=>r});var t={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["var","end_var"],["var_input","end_var"],["var_output","end_var"],["var_in_out","end_var"],["var_temp","end_var"],["var_global","end_var"],["var_access","end_var"],["var_external","end_var"],["type","end_type"],["struct","end_struct"],["program","end_program"],["function","end_function"],["function_block","end_function_block"],["action","end_action"],["step","end_step"],["initial_step","end_step"],["transaction","end_transaction"],["configuration","end_configuration"],["tcp","end_tcp"],["recource","end_recource"],["channel","end_channel"],["library","end_library"],["folder","end_folder"],["binaries","end_binaries"],["includes","end_includes"],["sources","end_sources"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"/*",close:"*/"},{open:"'",close:"'",notIn:["string_sq"]},{open:'"',close:'"',notIn:["string_dq"]},{open:"var_input",close:"end_var"},{open:"var_output",close:"end_var"},{open:"var_in_out",close:"end_var"},{open:"var_temp",close:"end_var"},{open:"var_global",close:"end_var"},{open:"var_access",close:"end_var"},{open:"var_external",close:"end_var"},{open:"type",close:"end_type"},{open:"struct",close:"end_struct"},{open:"program",close:"end_program"},{open:"function",close:"end_function"},{open:"function_block",close:"end_function_block"},{open:"action",close:"end_action"},{open:"step",close:"end_step"},{open:"initial_step",close:"end_step"},{open:"transaction",close:"end_transaction"},{open:"configuration",close:"end_configuration"},{open:"tcp",close:"end_tcp"},{open:"recource",close:"end_recource"},{open:"channel",close:"end_channel"},{open:"library",close:"end_library"},{open:"folder",close:"end_folder"},{open:"binaries",close:"end_binaries"},{open:"includes",close:"end_includes"},{open:"sources",close:"end_sources"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"var",close:"end_var"},{open:"var_input",close:"end_var"},{open:"var_output",close:"end_var"},{open:"var_in_out",close:"end_var"},{open:"var_temp",close:"end_var"},{open:"var_global",close:"end_var"},{open:"var_access",close:"end_var"},{open:"var_external",close:"end_var"},{open:"type",close:"end_type"},{open:"struct",close:"end_struct"},{open:"program",close:"end_program"},{open:"function",close:"end_function"},{open:"function_block",close:"end_function_block"},{open:"action",close:"end_action"},{open:"step",close:"end_step"},{open:"initial_step",close:"end_step"},{open:"transaction",close:"end_transaction"},{open:"configuration",close:"end_configuration"},{open:"tcp",close:"end_tcp"},{open:"recource",close:"end_recource"},{open:"channel",close:"end_channel"},{open:"library",close:"end_library"},{open:"folder",close:"end_folder"},{open:"binaries",close:"end_binaries"},{open:"includes",close:"end_includes"},{open:"sources",close:"end_sources"}],folding:{markers:{start:new RegExp("^\\s*#pragma\\s+region\\b"),end:new RegExp("^\\s*#pragma\\s+endregion\\b")}}},r={defaultToken:"",tokenPostfix:".st",ignoreCase:!0,brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:["if","end_if","elsif","else","case","of","to","__try","__catch","__finally","do","with","by","while","repeat","end_while","end_repeat","end_case","for","end_for","task","retain","non_retain","constant","with","at","exit","return","interval","priority","address","port","on_channel","then","iec","file","uses","version","packagetype","displayname","copyright","summary","vendor","common_source","from","extends","implements"],constant:["false","true","null"],defineKeywords:["var","var_input","var_output","var_in_out","var_temp","var_global","var_access","var_external","end_var","type","end_type","struct","end_struct","program","end_program","function","end_function","function_block","end_function_block","interface","end_interface","method","end_method","property","end_property","namespace","end_namespace","configuration","end_configuration","tcp","end_tcp","resource","end_resource","channel","end_channel","library","end_library","folder","end_folder","binaries","end_binaries","includes","end_includes","sources","end_sources","action","end_action","step","initial_step","end_step","transaction","end_transaction"],typeKeywords:["int","sint","dint","lint","usint","uint","udint","ulint","real","lreal","time","date","time_of_day","date_and_time","string","bool","byte","word","dword","array","pointer","lword"],operators:["=",">","<",":",":=","<=",">=","<>","&","+","-","*","**","MOD","^","or","and","not","xor","abs","acos","asin","atan","cos","exp","expt","ln","log","sin","sqrt","tan","sel","max","min","limit","mux","shl","shr","rol","ror","indexof","sizeof","adr","adrinst","bitadr","is_valid","ref","ref_to"],builtinVariables:[],builtinFunctions:["sr","rs","tp","ton","tof","eq","ge","le","lt","ne","round","trunc","ctd","\u0441tu","ctud","r_trig","f_trig","move","concat","delete","find","insert","left","len","replace","right","rtc"],symbols:/[=>{a.d(t,{B:()=>d});var n=a(59284),s=a(84476),r=a(84375),i=a(55974),o=a(42829),l=a(60712);function d({children:e,onConfirmAction:t,onConfirmActionSuccess:a,dialogHeader:d,dialogText:c,retryButtonText:u,buttonDisabled:h=!1,buttonView:b="action",buttonTitle:p,buttonClassName:m,withPopover:v=!1,popoverContent:g,popoverPlacement:y="right",popoverDisabled:x=!0}){const[w,j]=n.useState(!1),[f,T]=n.useState(!1),[N,S]=n.useState(!1),C=()=>(0,l.jsx)(s.$,{onClick:()=>j(!0),view:b,disabled:h,loading:!h&&f,className:m,title:p,children:e});return(0,l.jsxs)(n.Fragment,{children:[(0,l.jsx)(i.g,{visible:w,header:d,text:c,withRetry:N,retryButtonText:u,onConfirm:async e=>{T(!0),await t(e)},onConfirmActionSuccess:async()=>{S(!1);try{await(null===a||void 0===a?void 0:a())}finally{T(!1)}},onConfirmActionError:e=>{S((0,o.D)(e)),T(!1)},onClose:()=>{j(!1)}}),v?(0,l.jsx)(r.A,{content:g,placement:y,disabled:x,children:C()}):C()]})}},55974:(e,t,a)=>{a.d(t,{g:()=>g});var n=a(59284),s=a(18677),r=a(71153),i=a(74321),o=a(2198),l=a(99991),d=a(89954),c=a(77506),u=a(48372);const h=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),b=(0,u.g4)("ydb-critical-action-dialog",{en:h});var p=a(60712);const m=(0,c.cn)("ydb-critical-dialog"),v=e=>e.data&&"issues"in e.data&&e.data.issues?(0,p.jsx)(d.O,{hideSeverity:!0,data:e.data}):403===e.status?b("no-rights-error"):e.statusText?e.statusText:b("default-error");function g({visible:e,header:t,text:a,withRetry:d,retryButtonText:c,withCheckBox:u,onClose:h,onConfirm:g,onConfirmActionSuccess:y,onConfirmActionError:x}){const[w,j]=n.useState(!1),[f,T]=n.useState(),[N,S]=n.useState(!1),C=async e=>(j(!0),g(e).then((()=>{y(),h()})).catch((e=>{x(e),T(e)})).finally((()=>{j(!1)})));return(0,p.jsx)(o.l,{open:e,hasCloseButton:!1,className:m(),size:"s",onClose:h,onTransitionExited:()=>{T(void 0),S(!1)},children:f?(0,p.jsxs)(n.Fragment,{children:[(0,p.jsx)(o.l.Header,{caption:t}),(0,p.jsx)(o.l.Body,{className:m("body"),children:(0,p.jsxs)("div",{className:m("body-message",{error:!0}),children:[(0,p.jsx)("span",{className:m("error-icon"),children:(0,p.jsx)(s.A,{width:"24",height:"22"})}),v(f)]})}),(0,p.jsx)(o.l.Footer,{loading:!1,preset:"default",textButtonApply:d?c||b("button-retry"):void 0,textButtonCancel:b("button-close"),onClickButtonApply:()=>C(!0),onClickButtonCancel:h})]}):(0,p.jsxs)(n.Fragment,{children:[(0,p.jsx)(o.l.Header,{caption:t}),(0,p.jsxs)(o.l.Body,{className:m("body"),children:[(0,p.jsxs)("div",{className:m("body-message",{warning:!0}),children:[(0,p.jsx)("span",{className:m("warning-icon"),children:(0,p.jsx)(l.I,{data:r.A,size:24})}),a]}),u?(0,p.jsx)(i.S,{checked:N,onUpdate:S,children:b("checkbox-text")}):null]}),(0,p.jsx)(o.l.Footer,{loading:w,preset:"default",textButtonApply:b("button-confirm"),textButtonCancel:b("button-cancel"),propsButtonApply:{type:"submit",disabled:u&&!N},onClickButtonCancel:h,onClickButtonApply:()=>C()})]})})}},42829:(e,t,a)=>{a.d(t,{D:()=>n});const n=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},52248:(e,t,a)=>{a.d(t,{a:()=>n.a});var n=a(47334)},17594:(e,t,a)=>{a.d(t,{l:()=>d});var n=a(69024),s=a(4557),r=a(77506),i=a(16819),o=a(60712);const l=(0,r.cn)("ydb-resizeable-data-table");function d({columnsWidthLSKey:e,columns:t,settings:a,wrapperClassName:r,...d}){const[c,u]=(0,i.a)(e),h=(0,n.j)(t,c),b={...a,defaultResizeable:!0};return(0,o.jsx)("div",{className:l(null,r),children:(0,o.jsx)(s.Ay,{theme:"yandex-cloud",columns:h,onResize:u,settings:b,...d})})}},80420:(e,t,a)=>{a.d(t,{$:()=>v});var n=a(40336),s=a(63291),r=a(92459),i=a(78668),o=a(31684),l=a(90182),d=a(71661),c=a(10508),u=a(25196),h=a(48372);const b=JSON.parse('{"field_links":"Links","context_developer-ui":"Developer UI"}'),p=(0,h.g4)("ydb-tablet-name-wrapper",{en:b});var m=a(60712);function v({tabletId:e,database:t}){const a=(0,l.N4)(i._5),h=(0,r.DM)(e,{database:t});return(0,m.jsx)(d.s,{disabled:!a,delayClosing:200,content:(0,m.jsx)(n.u,{responsive:!0,children:(0,m.jsx)(n.u.Item,{name:p("field_links"),children:(0,m.jsx)(u.K,{title:p("context_developer-ui"),url:(0,o._t)(e)})})}),placement:["top","bottom"],behavior:s.m.Immediate,children:(0,m.jsx)(c.c,{name:e.toString(),path:h,hasClipboardButton:!0,showStatus:!1})})}},27775:(e,t,a)=>{a.d(t,{i:()=>i});var n=a(47665),s=a(58267),r=a(60712);function i({state:e}){return(0,r.jsx)(n.J,{theme:(0,s._)(e),children:e})}},88616:(e,t,a)=>{a.d(t,{Q:()=>C});var n=a(76938),s=a(98089),r=a(99991),i=a(22983),o=a(10508),l=a(44294),d=a(17594),c=a(19228),u=a(80420),h=a(27775),b=a(41826),p=a(78668),m=a(21545),v=a(6354),g=a(76086),y=a(90182),x=a(29819),w=a(48372);const j=JSON.parse('{"noTabletsData":"No tablets data","Type":"Type","Tablet":"Tablet","State":"State","Node ID":"Node ID","Node FQDN":"Node FQDN","Generation":"Generation","Uptime":"Uptime","dialog.kill-header":"Restart tablet","dialog.kill-text":"The tablet will be restarted. Do you want to proceed?","controls.kill-not-allowed":"You don\'t have enough rights to restart tablet"}'),f=(0,w.g4)("ydb-tablets",{en:j});var T=a(60712);function N({database:e}){return[{name:"Type",width:150,get header(){return f("Type")},render:({row:e})=>{const t=!1===e.Leader;return(0,T.jsxs)("span",{children:[e.Type," ",t?(0,T.jsx)(s.E,{color:"secondary",children:"follower"}):""]})}},{name:"TabletId",width:220,get header(){return f("Tablet")},render:({row:t})=>t.TabletId?(0,T.jsx)(u.$,{tabletId:t.TabletId,database:e}):g.Pd},{name:"State",get header(){return f("State")},render:({row:e})=>(0,T.jsx)(h.i,{state:e.State})},{name:"NodeId",get header(){return f("Node ID")},render:({row:e})=>{const t=void 0===e.NodeId?void 0:(0,x.vI)(e.NodeId);return(0,T.jsx)(l.E,{to:t,children:e.NodeId})},align:"right"},{name:"fqdn",get header(){return f("Node FQDN")},render:({row:e})=>e.fqdn?(0,T.jsx)(o.c,{name:e.fqdn,showStatus:!1,hasClipboardButton:!0}):(0,T.jsx)("span",{children:"\u2014"})},{name:"Generation",get header(){return f("Generation")},align:"right"},{name:"Uptime",get header(){return f("Uptime")},render:({row:e})=>(0,T.jsx)(b.H,{ChangeTime:e.ChangeTime}),sortAccessor:e=>-Number(e.ChangeTime),align:"right",width:120},{name:"Actions",sortable:!1,resizeable:!1,header:"",render:({row:e})=>(0,T.jsx)(S,{...e})}]}function S(e){const t=e.State===v.r.Stopped,a=(0,y.N4)(p._5),[s]=m.X.useKillTabletMutation(),o=e.TabletId;return o?(0,T.jsx)(i.B,{buttonView:"outlined",buttonTitle:f("dialog.kill-header"),dialogHeader:f("dialog.kill-header"),dialogText:f("dialog.kill-text"),onConfirmAction:()=>s({id:o}).unwrap(),buttonDisabled:t||!a,withPopover:!0,popoverContent:f(a?"dialog.kill-header":"controls.kill-not-allowed"),popoverPlacement:["right","auto"],popoverDisabled:!1,children:(0,T.jsx)(r.I,{data:n.A})}):null}function C({database:e,tablets:t,className:a,loading:n}){return n?(0,T.jsx)(c.Q,{}):(0,T.jsx)(d.l,{wrapperClassName:a,columns:N({database:e}),data:t,settings:g.N3,emptyDataMessage:f("noTabletsData")})}},89954:(e,t,a)=>{a.d(t,{O:()=>C});var n=a(59284),s=a(45720),r=a(16929),i=a(71153),o=a(18677),l=a(84476),d=a(33705),c=a(67884),u=a(99991),h=a(77506),b=a(48372);const p=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),m=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),v=(0,b.g4)("ydb-shorty-string",{ru:m,en:p});var g=a(60712);const y=(0,h.cn)("kv-shorty-string");function x({value:e="",limit:t=200,strict:a=!1,displayLength:s=!0,render:r=e=>e,onToggle:i,expandLabel:o=v("default_expand_label"),collapseLabel:l=v("default_collapse_label")}){const[d,u]=n.useState(!1),h=(d?l:o)+(s&&!d?v("chars_count",{count:e.length}):""),b=e.length>t+(a?0:h.length),p=d||!b?e:e.slice(0,t-4)+"\xa0...";return(0,g.jsxs)("div",{className:y(),children:[r(p),b?(0,g.jsx)(c.N,{className:y("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),u((e=>!e)),null===i||void 0===i||i()},children:h}):null]})}var w=a(41650);const j=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function f(e){return function(e){return!!e&&void 0!==j[e]}(e)?j[e]:"S_INFO"}const T=(0,h.cn)("kv-result-issues"),N=(0,h.cn)("kv-issues"),S=(0,h.cn)("kv-issue");function C({data:e,hideSeverity:t}){const[a,s]=n.useState(!1),r="string"===typeof e||null===e||void 0===e?void 0:e.issues,i=Array.isArray(r)&&r.length>0;return(0,g.jsxs)("div",{className:T(),children:[(0,g.jsxs)("div",{className:T("error-message"),children:[(()=>{let a;if("string"===typeof e)a=e;else{var s,r;const i=f(null===e||void 0===e||null===(s=e.error)||void 0===s?void 0:s.severity);a=(0,g.jsxs)(n.Fragment,{children:[t?null:(0,g.jsxs)(n.Fragment,{children:[(0,g.jsx)(B,{severity:i})," "]}),(0,g.jsx)("span",{className:T("error-message-text"),children:null===e||void 0===e||null===(r=e.error)||void 0===r?void 0:r.message})]})}return a})(),i&&(0,g.jsx)(l.$,{view:"normal",onClick:()=>s(!a),children:a?"Hide details":"Show details"})]}),i&&a&&(0,g.jsx)(I,{hideSeverity:t,issues:r})]})}function I({issues:e,hideSeverity:t}){const a=null===e||void 0===e?void 0:e.reduce(((e,t)=>{var a;const n=null!==(a=t.severity)&&void 0!==a?a:10;return Math.min(e,n)}),10);return(0,g.jsx)("div",{className:N(null),children:null===e||void 0===e?void 0:e.map(((e,n)=>(0,g.jsx)(k,{hideSeverity:t,issue:e,expanded:e===a},n)))})}function k({issue:e,hideSeverity:t,level:a=0}){const[s,r]=n.useState(!0),i=f(e.severity),o=e.issues,c=Array.isArray(o)&&o.length>0,u=s?"bottom":"right";return(0,g.jsxs)("div",{className:S({leaf:!c,"has-issues":c}),children:[(0,g.jsxs)("div",{className:S("line"),children:[c&&(0,g.jsx)(l.$,{view:"flat-secondary",onClick:()=>r(!s),className:S("arrow-toggle"),children:(0,g.jsx)(d.I,{direction:u,size:16})}),t?null:(0,g.jsx)(B,{severity:i}),(0,g.jsx)(_,{issue:e}),e.issue_code?(0,g.jsxs)("span",{className:S("code"),children:["Code: ",e.issue_code]}):null]}),c&&s&&(0,g.jsx)("div",{className:S("issues"),children:(0,g.jsx)(A,{issues:o,level:a+1,expanded:s})})]})}function _({issue:e}){var t;const a=function(e){const{position:t}=e;if("object"!==typeof t||null===t||!(0,w.kf)(t.row))return"";const{row:a,column:n}=t;return(0,w.kf)(n)?`${a}:${n}`:`line ${a}`}(e),n=window.ydbEditor,s=()=>(0,g.jsxs)("span",{className:S("message"),children:[a&&(0,g.jsx)("span",{className:S("place-text"),title:"Position",children:a}),(0,g.jsx)("div",{className:S("message-text"),children:(0,g.jsx)(x,{value:e.message,expandLabel:"Show full message"})})]}),{row:r,column:i}=null!==(t=e.position)&&void 0!==t?t:{};if(!((0,w.kf)(r)&&n))return s();return(0,g.jsx)(c.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:r,column:null!==i&&void 0!==i?i:0};n.setPosition(e),n.revealPositionInCenterIfOutsideViewport(e),n.focus()},view:"primary",children:s()})}function A(e){const{issues:t,level:a,expanded:n}=e;return(0,g.jsx)("div",{className:S("list"),children:t.map(((e,t)=>(0,g.jsx)(k,{issue:e,level:a,expanded:n},t)))})}const F={S_INFO:s.A,S_WARNING:r.A,S_ERROR:i.A,S_FATAL:o.A},D=(0,h.cn)("yql-issue-severity");function B({severity:e}){const t=e.slice(2).toLowerCase();return(0,g.jsxs)("span",{className:D({severity:t}),children:[(0,g.jsx)(u.I,{className:D("icon"),data:F[e]}),(0,g.jsx)("span",{className:D("title"),children:t})]})}},21545:(e,t,a)=>{a.d(t,{X:()=>s});var n=a(78034);const s=a(21334).F.injectEndpoints({endpoints:e=>({getTablet:e.query({queryFn:async({id:e,database:t},{signal:a})=>{try{const[s,r,i]=await Promise.all([window.api.viewer.getTablet({id:e,database:t},{signal:a}),window.api.viewer.getTabletHistory({id:e,database:t},{signal:a}),window.api.viewer.getNodesList({signal:a})]),o=(0,n.nN)(i),l=Object.keys(r).reduce(((e,t)=>{var a;const n=null===(a=r[t])||void 0===a?void 0:a.TabletStateInfo;if(n&&n.length){var s;const a=n.find((e=>e.Leader))||n[0],{ChangeTime:r,Generation:i,State:l,Leader:d,FollowerId:c}=a,u=o&&t?null===(s=o.get(Number(t)))||void 0===s?void 0:s.Host:void 0;"Dead"!==l&&e.push({nodeId:t,generation:i,changeTime:r,state:l,leader:d,followerId:c,fqdn:u})}return e}),[]),{TabletStateInfo:d=[]}=s,[c={}]=d,{TabletId:u}=c;return{data:{id:u,data:c,history:l}}}catch(s){return{error:s}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),getTabletDescribe:e.query({queryFn:async({tenantId:e},{signal:t})=>{try{const a=await window.api.viewer.getTabletDescribe(e,{signal:t}),{SchemeShard:n,PathId:s}=e;return{data:(null===a||void 0===a?void 0:a.Path)||`${n}:${s}`}}catch(a){return{error:a}}},providesTags:["All"]}),getAdvancedTableInfo:e.query({queryFn:async({id:e,hiveId:t},{signal:a})=>{try{return{data:await window.api.tablets.getTabletFromHive({id:e,hiveId:t},{signal:a})}}catch(n){return{error:n}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),killTablet:e.mutation({queryFn:async({id:e})=>{try{return{data:await window.api.tablets.killTablet(e)}}catch(t){return{error:t}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),stopTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.stopTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),resumeTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.resumeTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"})}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/13470.82cfe328.chunk.js b/ydb/core/viewer/monitoring/static/js/13470.82cfe328.chunk.js new file mode 100644 index 000000000000..0ca612fc0728 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/13470.82cfe328.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[13470],{13470:(e,a,n)=>{n.d(a,{default:()=>o});var t=n(79243);const o=n.n(t)()},79243:e=>{function a(e){e.languages.erlang={comment:/%.+/,string:{pattern:/"(?:\\.|[^\\"\r\n])*"/,greedy:!0},"quoted-function":{pattern:/'(?:\\.|[^\\'\r\n])+'(?=\()/,alias:"function"},"quoted-atom":{pattern:/'(?:\\.|[^\\'\r\n])+'/,alias:"atom"},boolean:/\b(?:false|true)\b/,keyword:/\b(?:after|case|catch|end|fun|if|of|receive|try|when)\b/,number:[/\$\\?./,/\b\d+#[a-z0-9]+/i,/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?/i],function:/\b[a-z][\w@]*(?=\()/,variable:{pattern:/(^|[^@])(?:\b|\?)[A-Z_][\w@]*/,lookbehind:!0},operator:[/[=\/<>:]=|=[:\/]=|\+\+?|--?|[=*\/!]|\b(?:and|andalso|band|bnot|bor|bsl|bsr|bxor|div|not|or|orelse|rem|xor)\b/,{pattern:/(^|[^<])<(?!<)/,lookbehind:!0},{pattern:/(^|[^>])>(?!>)/,lookbehind:!0}],atom:/\b[a-z][\w@]*/,punctuation:/[()[\]{}:;,.#|]|<<|>>/}}e.exports=a,a.displayName="erlang",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/13638.e739b34f.chunk.js b/ydb/core/viewer/monitoring/static/js/13638.e739b34f.chunk.js new file mode 100644 index 000000000000..14f4dd268e36 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/13638.e739b34f.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 13638.e739b34f.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[13638],{13638:(e,t,s)=>{s.r(t),s.d(t,{conf:()=>r,language:()=>o});var r={comments:{lineComment:"#",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}]},o={defaultToken:"",tokenPostfix:".hcl",keywords:["var","local","path","for_each","any","string","number","bool","true","false","null","if ","else ","endif ","for ","in","endfor"],operators:["=",">=","<=","==","!=","+","-","*","/","%","&&","||","!","<",">","?","...",":"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"operator","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\d[\d']*/,"number"],[/\d/,"number"],[/[;,.]/,"delimiter"],[/"/,"string","@string"],[/'/,"invalid"]],heredoc:[[/<<[-]*\s*["]?([\w\-]+)["]?/,{token:"string.heredoc.delimiter",next:"@heredocBody.$1"}]],heredocBody:[[/([\w\-]+)$/,{cases:{"$1==$S2":[{token:"string.heredoc.delimiter",next:"@popall"}],"@default":"string.heredoc"}}],[/./,"string.heredoc"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"],[/#.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],string:[[/\$\{/,{token:"delimiter",next:"@stringExpression"}],[/[^\\"\$]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@popall"]],stringInsideExpression:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],stringExpression:[[/\}/,{token:"delimiter",next:"@pop"}],[/"/,"string","@stringInsideExpression"],{include:"@terraform"}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/118.112f7e2f.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/13638.e739b34f.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/118.112f7e2f.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/13638.e739b34f.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/1414.4cfda0bc.chunk.js b/ydb/core/viewer/monitoring/static/js/1414.4cfda0bc.chunk.js deleted file mode 100644 index 48cce62ac69f..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1414.4cfda0bc.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 1414.4cfda0bc.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1414],{51414:(e,t,r)=>{r.r(t),r.d(t,{conf:()=>s,language:()=>n});var s={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#%\^\&\*\(\)\=\$\-\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{blockComment:["###","###"],lineComment:"#"},folding:{markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},n={defaultToken:"",ignoreCase:!1,tokenPostfix:".mips",regEx:/\/(?!\/\/)(?:[^\/\\]|\\.)*\/[igm]*/,keywords:[".data",".text","syscall","trap","add","addu","addi","addiu","and","andi","div","divu","mult","multu","nor","or","ori","sll","slv","sra","srav","srl","srlv","sub","subu","xor","xori","lhi","lho","lhi","llo","slt","slti","sltu","sltiu","beq","bgtz","blez","bne","j","jal","jalr","jr","lb","lbu","lh","lhu","lw","li","la","sb","sh","sw","mfhi","mflo","mthi","mtlo","move"],symbols:/[\.,\:]+/,escapes:/\\(?:[abfnrtv\\"'$]|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[[/\$[a-zA-Z_]\w*/,"variable.predefined"],[/[.a-zA-Z_]\w*/,{cases:{this:"variable.predefined","@keywords":{token:"keyword.$0"},"@default":""}}],[/[ \t\r\n]+/,""],[/#.*$/,"comment"],["///",{token:"regexp",next:"@hereregexp"}],[/^(\s*)(@regEx)/,["","regexp"]],[/(\,)(\s*)(@regEx)/,["delimiter","","regexp"]],[/(\:)(\s*)(@regEx)/,["delimiter","","regexp"]],[/@symbols/,"delimiter"],[/\d+[eE]([\-+]?\d+)?/,"number.float"],[/\d+\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/0[0-7]+(?!\d)/,"number.octal"],[/\d+/,"number"],[/[,.]/,"delimiter"],[/"""/,"string",'@herestring."""'],[/'''/,"string","@herestring.'''"],[/"/,{cases:{"@eos":"string","@default":{token:"string",next:'@string."'}}}],[/'/,{cases:{"@eos":"string","@default":{token:"string",next:"@string.'"}}}]],string:[[/[^"'\#\\]+/,"string"],[/@escapes/,"string.escape"],[/\./,"string.escape.invalid"],[/\./,"string.escape.invalid"],[/#{/,{cases:{'$S2=="':{token:"string",next:"root.interpolatedstring"},"@default":"string"}}],[/["']/,{cases:{"$#==$S2":{token:"string",next:"@pop"},"@default":"string"}}],[/#/,"string"]],herestring:[[/("""|''')/,{cases:{"$1==$S2":{token:"string",next:"@pop"},"@default":"string"}}],[/[^#\\'"]+/,"string"],[/['"]+/,"string"],[/@escapes/,"string.escape"],[/\./,"string.escape.invalid"],[/#{/,{token:"string.quote",next:"root.interpolatedstring"}],[/#/,"string"]],comment:[[/[^#]+/,"comment"],[/#/,"comment"]],hereregexp:[[/[^\\\/#]+/,"regexp"],[/\\./,"regexp"],[/#.*$/,"comment"],["///[igm]*",{token:"regexp",next:"@pop"}],[/\//,"regexp"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1431.2bb62d12.chunk.js b/ydb/core/viewer/monitoring/static/js/1431.2bb62d12.chunk.js new file mode 100644 index 000000000000..399af47a72bc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/1431.2bb62d12.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1431],{1431:(e,a,n)=>{n.d(a,{default:()=>t});var r=n(46346);const t=n.n(r)()},46346:e=>{function a(e){e.languages.go=e.languages.extend("clike",{string:{pattern:/(^|[^\\])"(?:\\.|[^"\\\r\n])*"|`[^`]*`/,lookbehind:!0,greedy:!0},keyword:/\b(?:break|case|chan|const|continue|default|defer|else|fallthrough|for|func|go(?:to)?|if|import|interface|map|package|range|return|select|struct|switch|type|var)\b/,boolean:/\b(?:_|false|iota|nil|true)\b/,number:[/\b0(?:b[01_]+|o[0-7_]+)i?\b/i,/\b0x(?:[a-f\d_]+(?:\.[a-f\d_]*)?|\.[a-f\d_]+)(?:p[+-]?\d+(?:_\d+)*)?i?(?!\w)/i,/(?:\b\d[\d_]*(?:\.[\d_]*)?|\B\.\d[\d_]*)(?:e[+-]?[\d_]+)?i?(?!\w)/i],operator:/[*\/%^!=]=?|\+[=+]?|-[=-]?|\|[=|]?|&(?:=|&|\^=?)?|>(?:>=?|=)?|<(?:<=?|=|-)?|:=|\.\.\./,builtin:/\b(?:append|bool|byte|cap|close|complex|complex(?:64|128)|copy|delete|error|float(?:32|64)|u?int(?:8|16|32|64)?|imag|len|make|new|panic|print(?:ln)?|real|recover|rune|string|uintptr)\b/}),e.languages.insertBefore("go","string",{char:{pattern:/'(?:\\.|[^'\\\r\n]){0,10}'/,greedy:!0}}),delete e.languages.go["class-name"]}e.exports=a,a.displayName="go",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/14382.a8e3e5fd.chunk.js b/ydb/core/viewer/monitoring/static/js/14382.a8e3e5fd.chunk.js new file mode 100644 index 000000000000..956f429614d2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/14382.a8e3e5fd.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[14382],{14382:(e,n,t)=>{t.d(n,{default:()=>o});var a=t(36811);const o=t.n(a)()},36811:(e,n,t)=>{var a=t(51572);function o(e){e.register(a),function(e){e.languages.django={comment:/^\{#[\s\S]*?#\}$/,tag:{pattern:/(^\{%[+-]?\s*)\w+/,lookbehind:!0,alias:"keyword"},delimiter:{pattern:/^\{[{%][+-]?|[+-]?[}%]\}$/,alias:"punctuation"},string:{pattern:/("|')(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0},filter:{pattern:/(\|)\w+/,lookbehind:!0,alias:"function"},test:{pattern:/(\bis\s+(?:not\s+)?)(?!not\b)\w+/,lookbehind:!0,alias:"function"},function:/\b[a-z_]\w+(?=\s*\()/i,keyword:/\b(?:and|as|by|else|for|if|import|in|is|loop|not|or|recursive|with|without)\b/,operator:/[-+%=]=?|!=|\*\*?=?|\/\/?=?|<[<=>]?|>[=>]?|[&|^~]/,number:/\b\d+(?:\.\d+)?\b/,boolean:/[Ff]alse|[Nn]one|[Tt]rue/,variable:/\b\w+\b/,punctuation:/[{}[\](),.:;]/};var n=/\{\{[\s\S]*?\}\}|\{%[\s\S]*?%\}|\{#[\s\S]*?#\}/g,t=e.languages["markup-templating"];e.hooks.add("before-tokenize",(function(e){t.buildPlaceholders(e,"django",n)})),e.hooks.add("after-tokenize",(function(e){t.tokenizePlaceholders(e,"django")})),e.languages.jinja2=e.languages.django,e.hooks.add("before-tokenize",(function(e){t.buildPlaceholders(e,"jinja2",n)})),e.hooks.add("after-tokenize",(function(e){t.tokenizePlaceholders(e,"jinja2")}))}(e)}e.exports=o,o.displayName="django",o.aliases=["jinja2"]},51572:e=>{function n(e){!function(e){function n(e,n){return"___"+e.toUpperCase()+n+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,a,o,i){if(t.language===a){var r=t.tokenStack=[];t.code=t.code.replace(o,(function(e){if("function"===typeof i&&!i(e))return e;for(var o,s=r.length;-1!==t.code.indexOf(o=n(a,s));)++s;return r[s]=e,o})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,a){if(t.language===a&&t.tokenStack){t.grammar=e.languages[a];var o=0,i=Object.keys(t.tokenStack);!function r(s){for(var l=0;l=i.length);l++){var u=s[l];if("string"===typeof u||u.content&&"string"===typeof u.content){var c=i[o],d=t.tokenStack[c],g="string"===typeof u?u:u.content,p=n(a,c),f=g.indexOf(p);if(f>-1){++o;var k=g.substring(0,f),b=new e.Token(a,e.tokenize(d,t.grammar),"language-"+a,d),h=g.substring(f+p.length),m=[];k&&m.push.apply(m,r([k])),m.push(b),h&&m.push.apply(m,r([h])),"string"===typeof u?s.splice.apply(s,[l,1].concat(m)):u.content=m}}else u.content&&r(u.content)}return s}(t.tokens)}}}})}(e)}e.exports=n,n.displayName="markupTemplating",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/14542.fea67816.chunk.js b/ydb/core/viewer/monitoring/static/js/14542.fea67816.chunk.js new file mode 100644 index 000000000000..b84fca68ee83 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/14542.fea67816.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 14542.fea67816.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[14542],{14542:(e,o,t)=>{t.r(o),t.d(o,{conf:()=>n,language:()=>s});var n={comments:{lineComment:"#"},brackets:[["[","]"],["<",">"],["(",")"]],autoClosingPairs:[{open:"[",close:"]"},{open:"<",close:">"},{open:"(",close:")"}],surroundingPairs:[{open:"[",close:"]"},{open:"<",close:">"},{open:"(",close:")"}]},s={defaultToken:"",tokenPostfix:".pla",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"<",close:">",token:"delimiter.angle"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:[".i",".o",".mv",".ilb",".ob",".label",".type",".phase",".pair",".symbolic",".symbolic-output",".kiss",".p",".e",".end"],comment:/#.*$/,identifier:/[a-zA-Z]+[a-zA-Z0-9_\-]*/,plaContent:/[01\-~\|]+/,tokenizer:{root:[{include:"@whitespace"},[/@comment/,"comment"],[/\.([a-zA-Z_\-]+)/,{cases:{"@eos":{token:"keyword.$1"},"@keywords":{cases:{".type":{token:"keyword.$1",next:"@type"},"@default":{token:"keyword.$1",next:"@keywordArg"}}},"@default":{token:"keyword.$1"}}}],[/@identifier/,"identifier"],[/@plaContent/,"string"]],whitespace:[[/[ \t\r\n]+/,""]],type:[{include:"@whitespace"},[/\w+/,{token:"type",next:"@pop"}]],keywordArg:[[/[ \t\r\n]+/,{cases:{"@eos":{token:"",next:"@pop"},"@default":""}}],[/@comment/,"comment","@pop"],[/[<>()\[\]]/,{cases:{"@eos":{token:"@brackets",next:"@pop"},"@default":"@brackets"}}],[/\-?\d+/,{cases:{"@eos":{token:"number",next:"@pop"},"@default":"number"}}],[/@identifier/,{cases:{"@eos":{token:"identifier",next:"@pop"},"@default":"identifier"}}],[/[;=]/,{cases:{"@eos":{token:"delimiter",next:"@pop"},"@default":"delimiter"}}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/132.cf00f1e7.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/14542.fea67816.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/132.cf00f1e7.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/14542.fea67816.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/1486.8a488ae4.chunk.js b/ydb/core/viewer/monitoring/static/js/1486.8a488ae4.chunk.js deleted file mode 100644 index 98bd99f82173..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1486.8a488ae4.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1486],{71486:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"sd",weekdays:"\u0622\u0686\u0631_\u0633\u0648\u0645\u0631_\u0627\u06b1\u0627\u0631\u0648_\u0627\u0631\u0628\u0639_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639_\u0687\u0646\u0687\u0631".split("_"),months:"\u062c\u0646\u0648\u0631\u064a_\u0641\u064a\u0628\u0631\u0648\u0631\u064a_\u0645\u0627\u0631\u0686_\u0627\u067e\u0631\u064a\u0644_\u0645\u0626\u064a_\u062c\u0648\u0646_\u062c\u0648\u0644\u0627\u0621\u0650_\u0622\u06af\u0633\u067d_\u0633\u064a\u067e\u067d\u0645\u0628\u0631_\u0622\u06aa\u067d\u0648\u0628\u0631_\u0646\u0648\u0645\u0628\u0631_\u068a\u0633\u0645\u0628\u0631".split("_"),weekStart:1,weekdaysShort:"\u0622\u0686\u0631_\u0633\u0648\u0645\u0631_\u0627\u06b1\u0627\u0631\u0648_\u0627\u0631\u0628\u0639_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639_\u0687\u0646\u0687\u0631".split("_"),monthsShort:"\u062c\u0646\u0648\u0631\u064a_\u0641\u064a\u0628\u0631\u0648\u0631\u064a_\u0645\u0627\u0631\u0686_\u0627\u067e\u0631\u064a\u0644_\u0645\u0626\u064a_\u062c\u0648\u0646_\u062c\u0648\u0644\u0627\u0621\u0650_\u0622\u06af\u0633\u067d_\u0633\u064a\u067e\u067d\u0645\u0628\u0631_\u0622\u06aa\u067d\u0648\u0628\u0631_\u0646\u0648\u0645\u0628\u0631_\u068a\u0633\u0645\u0628\u0631".split("_"),weekdaysMin:"\u0622\u0686\u0631_\u0633\u0648\u0645\u0631_\u0627\u06b1\u0627\u0631\u0648_\u0627\u0631\u0628\u0639_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639_\u0687\u0646\u0687\u0631".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd\u060c D MMMM YYYY HH:mm"},relativeTime:{future:"%s \u067e\u0648\u0621",past:"%s \u0627\u06b3",s:"\u0686\u0646\u062f \u0633\u064a\u06aa\u0646\u068a",m:"\u0647\u06aa \u0645\u0646\u067d",mm:"%d \u0645\u0646\u067d",h:"\u0647\u06aa \u06aa\u0644\u0627\u06aa",hh:"%d \u06aa\u0644\u0627\u06aa",d:"\u0647\u06aa \u068f\u064a\u0646\u0647\u0646",dd:"%d \u068f\u064a\u0646\u0647\u0646",M:"\u0647\u06aa \u0645\u0647\u064a\u0646\u0648",MM:"%d \u0645\u0647\u064a\u0646\u0627",y:"\u0647\u06aa \u0633\u0627\u0644",yy:"%d \u0633\u0627\u0644"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1496.18b1eb19.chunk.js b/ydb/core/viewer/monitoring/static/js/1496.18b1eb19.chunk.js deleted file mode 100644 index 072789bff2a8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1496.18b1eb19.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1496],{51496:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"en-in",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},ordinal:function(e){var a=["th","st","nd","rd"],_=e%100;return"["+e+(a[(_-20)%10]||a[_]||a[0])+"]"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/15418.978d5fff.chunk.js b/ydb/core/viewer/monitoring/static/js/15418.978d5fff.chunk.js new file mode 100644 index 000000000000..e123b982db9a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/15418.978d5fff.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[15418],{15418:function(e,t,_){e.exports=function(e){"use strict";function t(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=t(e),d={name:"da",weekdays:"s\xf8ndag_mandag_tirsdag_onsdag_torsdag_fredag_l\xf8rdag".split("_"),weekdaysShort:"s\xf8n._man._tirs._ons._tors._fre._l\xf8r.".split("_"),weekdaysMin:"s\xf8._ma._ti._on._to._fr._l\xf8.".split("_"),months:"januar_februar_marts_april_maj_juni_juli_august_september_oktober_november_december".split("_"),monthsShort:"jan._feb._mar._apr._maj_juni_juli_aug._sept._okt._nov._dec.".split("_"),weekStart:1,ordinal:function(e){return e+"."},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY HH:mm",LLLL:"dddd [d.] D. MMMM YYYY [kl.] HH:mm"},relativeTime:{future:"om %s",past:"%s siden",s:"f\xe5 sekunder",m:"et minut",mm:"%d minutter",h:"en time",hh:"%d timer",d:"en dag",dd:"%d dage",M:"en m\xe5ned",MM:"%d m\xe5neder",y:"et \xe5r",yy:"%d \xe5r"}};return _.default.locale(d,null,!0),d}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/15542.e6a4dbf6.chunk.js b/ydb/core/viewer/monitoring/static/js/15542.e6a4dbf6.chunk.js new file mode 100644 index 000000000000..44394ddce9c3 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/15542.e6a4dbf6.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 15542.e6a4dbf6.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[15542],{15542:(e,t,a)=>{a.r(t),a.d(t,{conf:()=>n,language:()=>i});var n={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["[","]"],["(",")"],["{","}"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment","identifier"]},{open:"[",close:"]",notIn:["string","comment","identifier"]},{open:"(",close:")",notIn:["string","comment","identifier"]},{open:"{",close:"}",notIn:["string","comment","identifier"]}]},i={defaultToken:"",tokenPostfix:".pq",ignoreCase:!1,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"{",close:"}",token:"delimiter.brackets"},{open:"(",close:")",token:"delimiter.parenthesis"}],operatorKeywords:["and","not","or"],keywords:["as","each","else","error","false","if","in","is","let","meta","otherwise","section","shared","then","true","try","type"],constructors:["#binary","#date","#datetime","#datetimezone","#duration","#table","#time"],constants:["#infinity","#nan","#sections","#shared"],typeKeywords:["action","any","anynonnull","none","null","logical","number","time","date","datetime","datetimezone","duration","text","binary","list","record","table","function"],builtinFunctions:["Access.Database","Action.Return","Action.Sequence","Action.Try","ActiveDirectory.Domains","AdoDotNet.DataSource","AdoDotNet.Query","AdobeAnalytics.Cubes","AnalysisServices.Database","AnalysisServices.Databases","AzureStorage.BlobContents","AzureStorage.Blobs","AzureStorage.Tables","Binary.Buffer","Binary.Combine","Binary.Compress","Binary.Decompress","Binary.End","Binary.From","Binary.FromList","Binary.FromText","Binary.InferContentType","Binary.Length","Binary.ToList","Binary.ToText","BinaryFormat.7BitEncodedSignedInteger","BinaryFormat.7BitEncodedUnsignedInteger","BinaryFormat.Binary","BinaryFormat.Byte","BinaryFormat.ByteOrder","BinaryFormat.Choice","BinaryFormat.Decimal","BinaryFormat.Double","BinaryFormat.Group","BinaryFormat.Length","BinaryFormat.List","BinaryFormat.Null","BinaryFormat.Record","BinaryFormat.SignedInteger16","BinaryFormat.SignedInteger32","BinaryFormat.SignedInteger64","BinaryFormat.Single","BinaryFormat.Text","BinaryFormat.Transform","BinaryFormat.UnsignedInteger16","BinaryFormat.UnsignedInteger32","BinaryFormat.UnsignedInteger64","Byte.From","Character.FromNumber","Character.ToNumber","Combiner.CombineTextByDelimiter","Combiner.CombineTextByEachDelimiter","Combiner.CombineTextByLengths","Combiner.CombineTextByPositions","Combiner.CombineTextByRanges","Comparer.Equals","Comparer.FromCulture","Comparer.Ordinal","Comparer.OrdinalIgnoreCase","Csv.Document","Cube.AddAndExpandDimensionColumn","Cube.AddMeasureColumn","Cube.ApplyParameter","Cube.AttributeMemberId","Cube.AttributeMemberProperty","Cube.CollapseAndRemoveColumns","Cube.Dimensions","Cube.DisplayFolders","Cube.Measures","Cube.Parameters","Cube.Properties","Cube.PropertyKey","Cube.ReplaceDimensions","Cube.Transform","Currency.From","DB2.Database","Date.AddDays","Date.AddMonths","Date.AddQuarters","Date.AddWeeks","Date.AddYears","Date.Day","Date.DayOfWeek","Date.DayOfWeekName","Date.DayOfYear","Date.DaysInMonth","Date.EndOfDay","Date.EndOfMonth","Date.EndOfQuarter","Date.EndOfWeek","Date.EndOfYear","Date.From","Date.FromText","Date.IsInCurrentDay","Date.IsInCurrentMonth","Date.IsInCurrentQuarter","Date.IsInCurrentWeek","Date.IsInCurrentYear","Date.IsInNextDay","Date.IsInNextMonth","Date.IsInNextNDays","Date.IsInNextNMonths","Date.IsInNextNQuarters","Date.IsInNextNWeeks","Date.IsInNextNYears","Date.IsInNextQuarter","Date.IsInNextWeek","Date.IsInNextYear","Date.IsInPreviousDay","Date.IsInPreviousMonth","Date.IsInPreviousNDays","Date.IsInPreviousNMonths","Date.IsInPreviousNQuarters","Date.IsInPreviousNWeeks","Date.IsInPreviousNYears","Date.IsInPreviousQuarter","Date.IsInPreviousWeek","Date.IsInPreviousYear","Date.IsInYearToDate","Date.IsLeapYear","Date.Month","Date.MonthName","Date.QuarterOfYear","Date.StartOfDay","Date.StartOfMonth","Date.StartOfQuarter","Date.StartOfWeek","Date.StartOfYear","Date.ToRecord","Date.ToText","Date.WeekOfMonth","Date.WeekOfYear","Date.Year","DateTime.AddZone","DateTime.Date","DateTime.FixedLocalNow","DateTime.From","DateTime.FromFileTime","DateTime.FromText","DateTime.IsInCurrentHour","DateTime.IsInCurrentMinute","DateTime.IsInCurrentSecond","DateTime.IsInNextHour","DateTime.IsInNextMinute","DateTime.IsInNextNHours","DateTime.IsInNextNMinutes","DateTime.IsInNextNSeconds","DateTime.IsInNextSecond","DateTime.IsInPreviousHour","DateTime.IsInPreviousMinute","DateTime.IsInPreviousNHours","DateTime.IsInPreviousNMinutes","DateTime.IsInPreviousNSeconds","DateTime.IsInPreviousSecond","DateTime.LocalNow","DateTime.Time","DateTime.ToRecord","DateTime.ToText","DateTimeZone.FixedLocalNow","DateTimeZone.FixedUtcNow","DateTimeZone.From","DateTimeZone.FromFileTime","DateTimeZone.FromText","DateTimeZone.LocalNow","DateTimeZone.RemoveZone","DateTimeZone.SwitchZone","DateTimeZone.ToLocal","DateTimeZone.ToRecord","DateTimeZone.ToText","DateTimeZone.ToUtc","DateTimeZone.UtcNow","DateTimeZone.ZoneHours","DateTimeZone.ZoneMinutes","Decimal.From","Diagnostics.ActivityId","Diagnostics.Trace","DirectQueryCapabilities.From","Double.From","Duration.Days","Duration.From","Duration.FromText","Duration.Hours","Duration.Minutes","Duration.Seconds","Duration.ToRecord","Duration.ToText","Duration.TotalDays","Duration.TotalHours","Duration.TotalMinutes","Duration.TotalSeconds","Embedded.Value","Error.Record","Excel.CurrentWorkbook","Excel.Workbook","Exchange.Contents","Expression.Constant","Expression.Evaluate","Expression.Identifier","Facebook.Graph","File.Contents","Folder.Contents","Folder.Files","Function.From","Function.Invoke","Function.InvokeAfter","Function.IsDataSource","GoogleAnalytics.Accounts","Guid.From","HdInsight.Containers","HdInsight.Contents","HdInsight.Files","Hdfs.Contents","Hdfs.Files","Informix.Database","Int16.From","Int32.From","Int64.From","Int8.From","ItemExpression.From","Json.Document","Json.FromValue","Lines.FromBinary","Lines.FromText","Lines.ToBinary","Lines.ToText","List.Accumulate","List.AllTrue","List.Alternate","List.AnyTrue","List.Average","List.Buffer","List.Combine","List.Contains","List.ContainsAll","List.ContainsAny","List.Count","List.Covariance","List.DateTimeZones","List.DateTimes","List.Dates","List.Difference","List.Distinct","List.Durations","List.FindText","List.First","List.FirstN","List.Generate","List.InsertRange","List.Intersect","List.IsDistinct","List.IsEmpty","List.Last","List.LastN","List.MatchesAll","List.MatchesAny","List.Max","List.MaxN","List.Median","List.Min","List.MinN","List.Mode","List.Modes","List.NonNullCount","List.Numbers","List.PositionOf","List.PositionOfAny","List.Positions","List.Product","List.Random","List.Range","List.RemoveFirstN","List.RemoveItems","List.RemoveLastN","List.RemoveMatchingItems","List.RemoveNulls","List.RemoveRange","List.Repeat","List.ReplaceMatchingItems","List.ReplaceRange","List.ReplaceValue","List.Reverse","List.Select","List.Single","List.SingleOrDefault","List.Skip","List.Sort","List.StandardDeviation","List.Sum","List.Times","List.Transform","List.TransformMany","List.Union","List.Zip","Logical.From","Logical.FromText","Logical.ToText","MQ.Queue","MySQL.Database","Number.Abs","Number.Acos","Number.Asin","Number.Atan","Number.Atan2","Number.BitwiseAnd","Number.BitwiseNot","Number.BitwiseOr","Number.BitwiseShiftLeft","Number.BitwiseShiftRight","Number.BitwiseXor","Number.Combinations","Number.Cos","Number.Cosh","Number.Exp","Number.Factorial","Number.From","Number.FromText","Number.IntegerDivide","Number.IsEven","Number.IsNaN","Number.IsOdd","Number.Ln","Number.Log","Number.Log10","Number.Mod","Number.Permutations","Number.Power","Number.Random","Number.RandomBetween","Number.Round","Number.RoundAwayFromZero","Number.RoundDown","Number.RoundTowardZero","Number.RoundUp","Number.Sign","Number.Sin","Number.Sinh","Number.Sqrt","Number.Tan","Number.Tanh","Number.ToText","OData.Feed","Odbc.DataSource","Odbc.Query","OleDb.DataSource","OleDb.Query","Oracle.Database","Percentage.From","PostgreSQL.Database","RData.FromBinary","Record.AddField","Record.Combine","Record.Field","Record.FieldCount","Record.FieldNames","Record.FieldOrDefault","Record.FieldValues","Record.FromList","Record.FromTable","Record.HasFields","Record.RemoveFields","Record.RenameFields","Record.ReorderFields","Record.SelectFields","Record.ToList","Record.ToTable","Record.TransformFields","Replacer.ReplaceText","Replacer.ReplaceValue","RowExpression.Column","RowExpression.From","Salesforce.Data","Salesforce.Reports","SapBusinessWarehouse.Cubes","SapHana.Database","SharePoint.Contents","SharePoint.Files","SharePoint.Tables","Single.From","Soda.Feed","Splitter.SplitByNothing","Splitter.SplitTextByAnyDelimiter","Splitter.SplitTextByDelimiter","Splitter.SplitTextByEachDelimiter","Splitter.SplitTextByLengths","Splitter.SplitTextByPositions","Splitter.SplitTextByRanges","Splitter.SplitTextByRepeatedLengths","Splitter.SplitTextByWhitespace","Sql.Database","Sql.Databases","SqlExpression.SchemaFrom","SqlExpression.ToExpression","Sybase.Database","Table.AddColumn","Table.AddIndexColumn","Table.AddJoinColumn","Table.AddKey","Table.AggregateTableColumn","Table.AlternateRows","Table.Buffer","Table.Column","Table.ColumnCount","Table.ColumnNames","Table.ColumnsOfType","Table.Combine","Table.CombineColumns","Table.Contains","Table.ContainsAll","Table.ContainsAny","Table.DemoteHeaders","Table.Distinct","Table.DuplicateColumn","Table.ExpandListColumn","Table.ExpandRecordColumn","Table.ExpandTableColumn","Table.FillDown","Table.FillUp","Table.FilterWithDataTable","Table.FindText","Table.First","Table.FirstN","Table.FirstValue","Table.FromColumns","Table.FromList","Table.FromPartitions","Table.FromRecords","Table.FromRows","Table.FromValue","Table.Group","Table.HasColumns","Table.InsertRows","Table.IsDistinct","Table.IsEmpty","Table.Join","Table.Keys","Table.Last","Table.LastN","Table.MatchesAllRows","Table.MatchesAnyRows","Table.Max","Table.MaxN","Table.Min","Table.MinN","Table.NestedJoin","Table.Partition","Table.PartitionValues","Table.Pivot","Table.PositionOf","Table.PositionOfAny","Table.PrefixColumns","Table.Profile","Table.PromoteHeaders","Table.Range","Table.RemoveColumns","Table.RemoveFirstN","Table.RemoveLastN","Table.RemoveMatchingRows","Table.RemoveRows","Table.RemoveRowsWithErrors","Table.RenameColumns","Table.ReorderColumns","Table.Repeat","Table.ReplaceErrorValues","Table.ReplaceKeys","Table.ReplaceMatchingRows","Table.ReplaceRelationshipIdentity","Table.ReplaceRows","Table.ReplaceValue","Table.ReverseRows","Table.RowCount","Table.Schema","Table.SelectColumns","Table.SelectRows","Table.SelectRowsWithErrors","Table.SingleRow","Table.Skip","Table.Sort","Table.SplitColumn","Table.ToColumns","Table.ToList","Table.ToRecords","Table.ToRows","Table.TransformColumnNames","Table.TransformColumnTypes","Table.TransformColumns","Table.TransformRows","Table.Transpose","Table.Unpivot","Table.UnpivotOtherColumns","Table.View","Table.ViewFunction","TableAction.DeleteRows","TableAction.InsertRows","TableAction.UpdateRows","Tables.GetRelationships","Teradata.Database","Text.AfterDelimiter","Text.At","Text.BeforeDelimiter","Text.BetweenDelimiters","Text.Clean","Text.Combine","Text.Contains","Text.End","Text.EndsWith","Text.Format","Text.From","Text.FromBinary","Text.Insert","Text.Length","Text.Lower","Text.Middle","Text.NewGuid","Text.PadEnd","Text.PadStart","Text.PositionOf","Text.PositionOfAny","Text.Proper","Text.Range","Text.Remove","Text.RemoveRange","Text.Repeat","Text.Replace","Text.ReplaceRange","Text.Select","Text.Split","Text.SplitAny","Text.Start","Text.StartsWith","Text.ToBinary","Text.ToList","Text.Trim","Text.TrimEnd","Text.TrimStart","Text.Upper","Time.EndOfHour","Time.From","Time.FromText","Time.Hour","Time.Minute","Time.Second","Time.StartOfHour","Time.ToRecord","Time.ToText","Type.AddTableKey","Type.ClosedRecord","Type.Facets","Type.ForFunction","Type.ForRecord","Type.FunctionParameters","Type.FunctionRequiredParameters","Type.FunctionReturn","Type.Is","Type.IsNullable","Type.IsOpenRecord","Type.ListItem","Type.NonNullable","Type.OpenRecord","Type.RecordFields","Type.ReplaceFacets","Type.ReplaceTableKeys","Type.TableColumn","Type.TableKeys","Type.TableRow","Type.TableSchema","Type.Union","Uri.BuildQueryString","Uri.Combine","Uri.EscapeDataString","Uri.Parts","Value.Add","Value.As","Value.Compare","Value.Divide","Value.Equals","Value.Firewall","Value.FromText","Value.Is","Value.Metadata","Value.Multiply","Value.NativeQuery","Value.NullableEquals","Value.RemoveMetadata","Value.ReplaceMetadata","Value.ReplaceType","Value.Subtract","Value.Type","ValueAction.NativeStatement","ValueAction.Replace","Variable.Value","Web.Contents","Web.Page","WebAction.Request","Xml.Document","Xml.Tables"],builtinConstants:["BinaryEncoding.Base64","BinaryEncoding.Hex","BinaryOccurrence.Optional","BinaryOccurrence.Repeating","BinaryOccurrence.Required","ByteOrder.BigEndian","ByteOrder.LittleEndian","Compression.Deflate","Compression.GZip","CsvStyle.QuoteAfterDelimiter","CsvStyle.QuoteAlways","Culture.Current","Day.Friday","Day.Monday","Day.Saturday","Day.Sunday","Day.Thursday","Day.Tuesday","Day.Wednesday","ExtraValues.Error","ExtraValues.Ignore","ExtraValues.List","GroupKind.Global","GroupKind.Local","JoinAlgorithm.Dynamic","JoinAlgorithm.LeftHash","JoinAlgorithm.LeftIndex","JoinAlgorithm.PairwiseHash","JoinAlgorithm.RightHash","JoinAlgorithm.RightIndex","JoinAlgorithm.SortMerge","JoinKind.FullOuter","JoinKind.Inner","JoinKind.LeftAnti","JoinKind.LeftOuter","JoinKind.RightAnti","JoinKind.RightOuter","JoinSide.Left","JoinSide.Right","MissingField.Error","MissingField.Ignore","MissingField.UseNull","Number.E","Number.Epsilon","Number.NaN","Number.NegativeInfinity","Number.PI","Number.PositiveInfinity","Occurrence.All","Occurrence.First","Occurrence.Last","Occurrence.Optional","Occurrence.Repeating","Occurrence.Required","Order.Ascending","Order.Descending","Precision.Decimal","Precision.Double","QuoteStyle.Csv","QuoteStyle.None","RelativePosition.FromEnd","RelativePosition.FromStart","RoundingMode.AwayFromZero","RoundingMode.Down","RoundingMode.ToEven","RoundingMode.TowardZero","RoundingMode.Up","SapHanaDistribution.All","SapHanaDistribution.Connection","SapHanaDistribution.Off","SapHanaDistribution.Statement","SapHanaRangeOperator.Equals","SapHanaRangeOperator.GreaterThan","SapHanaRangeOperator.GreaterThanOrEquals","SapHanaRangeOperator.LessThan","SapHanaRangeOperator.LessThanOrEquals","SapHanaRangeOperator.NotEquals","TextEncoding.Ascii","TextEncoding.BigEndianUnicode","TextEncoding.Unicode","TextEncoding.Utf16","TextEncoding.Utf8","TextEncoding.Windows","TraceLevel.Critical","TraceLevel.Error","TraceLevel.Information","TraceLevel.Verbose","TraceLevel.Warning","WebMethod.Delete","WebMethod.Get","WebMethod.Head","WebMethod.Patch","WebMethod.Post","WebMethod.Put"],builtinTypes:["Action.Type","Any.Type","Binary.Type","BinaryEncoding.Type","BinaryOccurrence.Type","Byte.Type","ByteOrder.Type","Character.Type","Compression.Type","CsvStyle.Type","Currency.Type","Date.Type","DateTime.Type","DateTimeZone.Type","Day.Type","Decimal.Type","Double.Type","Duration.Type","ExtraValues.Type","Function.Type","GroupKind.Type","Guid.Type","Int16.Type","Int32.Type","Int64.Type","Int8.Type","JoinAlgorithm.Type","JoinKind.Type","JoinSide.Type","List.Type","Logical.Type","MissingField.Type","None.Type","Null.Type","Number.Type","Occurrence.Type","Order.Type","Password.Type","Percentage.Type","Precision.Type","QuoteStyle.Type","Record.Type","RelativePosition.Type","RoundingMode.Type","SapHanaDistribution.Type","SapHanaRangeOperator.Type","Single.Type","Table.Type","Text.Type","TextEncoding.Type","Time.Type","TraceLevel.Type","Type.Type","Uri.Type","WebMethod.Type"],tokenizer:{root:[[/#"[\w \.]+"/,"identifier.quote"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/\d+([eE][\-+]?\d+)?/,"number"],[/(#?[a-z]+)\b/,{cases:{"@typeKeywords":"type","@keywords":"keyword","@constants":"constant","@constructors":"constructor","@operatorKeywords":"operators","@default":"identifier"}}],[/\b([A-Z][a-zA-Z0-9]+\.Type)\b/,{cases:{"@builtinTypes":"type","@default":"identifier"}}],[/\b([A-Z][a-zA-Z0-9]+\.[A-Z][a-zA-Z0-9]+)\b/,{cases:{"@builtinFunctions":"keyword.function","@builtinConstants":"constant","@default":"identifier"}}],[/\b([a-zA-Z_][\w\.]*)\b/,"identifier"],{include:"@whitespace"},{include:"@comments"},{include:"@strings"},[/[{}()\[\]]/,"@brackets"],[/([=\+<>\-\*&@\?\/!])|([<>]=)|(<>)|(=>)|(\.\.\.)|(\.\.)/,"operators"],[/[,;]/,"delimiter"]],whitespace:[[/\s+/,"white"]],comments:[["\\/\\*","comment","@comment"],["\\/\\/+.*","comment"]],comment:[["\\*\\/","comment","@pop"],[".","comment"]],strings:[['"',"string","@string"]],string:[['""',"string.escape"],['"',"string","@pop"],[".","string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1321.401aa9b8.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/15542.e6a4dbf6.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/1321.401aa9b8.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/15542.e6a4dbf6.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/15931.ad3d689f.chunk.js b/ydb/core/viewer/monitoring/static/js/15931.ad3d689f.chunk.js new file mode 100644 index 000000000000..c663c693fca7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/15931.ad3d689f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[15931],{15931:(a,e,n)=>{n.d(e,{default:()=>t});var i=n(36868);const t=n.n(i)()},36868:a=>{function e(a){!function(a){var e=/(?:\r?\n|\r)[ \t]*\|.+\|(?:(?!\|).)*/.source;a.languages.gherkin={pystring:{pattern:/("""|''')[\s\S]+?\1/,alias:"string"},comment:{pattern:/(^[ \t]*)#.*/m,lookbehind:!0},tag:{pattern:/(^[ \t]*)@\S*/m,lookbehind:!0},feature:{pattern:/((?:^|\r?\n|\r)[ \t]*)(?:Ability|Ahoy matey!|Arwedd|Aspekt|Besigheid Behoefte|Business Need|Caracteristica|Caracter\xedstica|Egenskab|Egenskap|Eiginleiki|Feature|F\u012b\u010da|Fitur|Fonctionnalit\xe9|Fonksyonalite|Funcionalidade|Funcionalitat|Functionalitate|Func\u0163ionalitate|Func\u021bionalitate|Functionaliteit|Fungsi|Funkcia|Funkcija|Funkcionalit\u0101te|Funkcionalnost|Funkcja|Funksie|Funktionalit\xe4t|Funktionalit\xe9it|Funzionalit\xe0|Hwaet|Hw\xe6t|Jellemz\u0151|Karakteristik|Lastnost|Mak|Mogucnost|laH|Mogu\u0107nost|Moznosti|Mo\u017enosti|OH HAI|Omadus|Ominaisuus|Osobina|\xd6zellik|Potrzeba biznesowa|perbogh|poQbogh malja'|Po\u017eadavek|Po\u017eiadavka|Pretty much|Qap|Qu'meH 'ut|Savyb\u0117|T\xednh n\u0103ng|Trajto|Vermo\xeb|Vlastnos\u0165|W\u0142a\u015bciwo\u015b\u0107|Zna\u010dilnost|\u0394\u03c5\u03bd\u03b1\u03c4\u03cc\u03c4\u03b7\u03c4\u03b1|\u039b\u03b5\u03b9\u03c4\u03bf\u03c5\u03c1\u03b3\u03af\u03b1|\u041c\u043e\u0433\u0443\u045b\u043d\u043e\u0441\u0442|\u041c\u04e9\u043c\u043a\u0438\u043d\u043b\u0435\u043a|\u041e\u0441\u043e\u0431\u0438\u043d\u0430|\u0421\u0432\u043e\u0439\u0441\u0442\u0432\u043e|\u04ae\u0437\u0435\u043d\u0447\u04d9\u043b\u0435\u043a\u043b\u0435\u043b\u0435\u043a|\u0424\u0443\u043d\u043a\u0446\u0438\u043e\u043d\u0430\u043b|\u0424\u0443\u043d\u043a\u0446\u0438\u043e\u043d\u0430\u043b\u043d\u043e\u0441\u0442|\u0424\u0443\u043d\u043a\u0446\u0438\u044f|\u0424\u0443\u043d\u043a\u0446\u0456\u043e\u043d\u0430\u043b|\u05ea\u05db\u05d5\u05e0\u05d4|\u062e\u0627\u0635\u064a\u0629|\u062e\u0635\u0648\u0635\u06cc\u062a|\u0635\u0644\u0627\u062d\u06cc\u062a|\u06a9\u0627\u0631\u0648\u0628\u0627\u0631 \u06a9\u06cc \u0636\u0631\u0648\u0631\u062a|\u0648\u0650\u06cc\u0698\u06af\u06cc|\u0930\u0942\u092a \u0932\u0947\u0916|\u0a16\u0a3e\u0a38\u0a40\u0a05\u0a24|\u0a28\u0a15\u0a36 \u0a28\u0a41\u0a39\u0a3e\u0a30|\u0a2e\u0a41\u0a39\u0a3e\u0a02\u0a26\u0a30\u0a3e|\u0c17\u0c41\u0c23\u0c2e\u0c41|\u0cb9\u0cc6\u0c9a\u0ccd\u0c9a\u0cb3|\u0e04\u0e27\u0e32\u0e21\u0e15\u0e49\u0e2d\u0e07\u0e01\u0e32\u0e23\u0e17\u0e32\u0e07\u0e18\u0e38\u0e23\u0e01\u0e34\u0e08|\u0e04\u0e27\u0e32\u0e21\u0e2a\u0e32\u0e21\u0e32\u0e23\u0e16|\u0e42\u0e04\u0e23\u0e07\u0e2b\u0e25\u0e31\u0e01|\uae30\ub2a5|\u30d5\u30a3\u30fc\u30c1\u30e3|\u529f\u80fd|\u6a5f\u80fd):(?:[^:\r\n]+(?:\r?\n|\r|$))*/,lookbehind:!0,inside:{important:{pattern:/(:)[^\r\n]+/,lookbehind:!0},keyword:/[^:\r\n]+:/}},scenario:{pattern:/(^[ \t]*)(?:Abstract Scenario|Abstrakt Scenario|Achtergrond|Aer|\xc6r|Agtergrond|All y'all|Antecedentes|Antecedents|Atbur\xf0ar\xe1s|Atbur\xf0ar\xe1sir|Awww, look mate|B4|Background|Baggrund|Bakgrund|Bakgrunn|Bakgrunnur|Beispiele|Beispiller|B\u1ed1i c\u1ea3nh|Cefndir|Cenario|Cen\xe1rio|Cenario de Fundo|Cen\xe1rio de Fundo|Cenarios|Cen\xe1rios|Contesto|Context|Contexte|Contexto|Conto|Contoh|Contone|D\xe6mi|Dasar|Dead men tell no tales|Delineacao do Cenario|Delinea\xe7\xe3o do Cen\xe1rio|Dis is what went down|D\u1eef li\u1ec7u|Dyagram Senaryo|Dyagram senaryo|Egzanp|Ejemplos|Eksempler|Ekzemploj|Enghreifftiau|Esbozo do escenario|Escenari|Escenario|Esempi|Esquema de l'escenari|Esquema del escenario|Esquema do Cenario|Esquema do Cen\xe1rio|EXAMPLZ|Examples|Exempel|Exemple|Exemples|Exemplos|First off|Fono|Forgat\xf3k\xf6nyv|Forgat\xf3k\xf6nyv v\xe1zlat|Fundo|Ge\xe7mi\u015f|Grundlage|Hannergrond|ghantoH|H\xe1tt\xe9r|Heave to|Istorik|Juhtumid|Keadaan|Khung k\u1ecbch b\u1ea3n|Khung t\xecnh hu\u1ed1ng|K\u1ecbch b\u1ea3n|Koncept|Konsep skenario|Kont\xe8ks|Kontekst|Kontekstas|Konteksts|Kontext|Konturo de la scenaro|Latar Belakang|lut chovnatlh|lut|lutmey|L\xfdsing Atbur\xf0ar\xe1sar|L\xfdsing D\xe6ma|MISHUN SRSLY|MISHUN|Menggariskan Senario|mo'|N\xe1\u010drt Scen\xe1ra|N\xe1\u010drt Sc\xe9n\xe1\u0159e|N\xe1\u010drt Scen\xe1ru|Oris scenarija|\xd6rnekler|Osnova|Osnova Scen\xe1ra|Osnova sc\xe9n\xe1\u0159e|Osnutek|Ozadje|Paraugs|Pavyzd\u017eiai|P\xe9ld\xe1k|Piem\u0113ri|Plan du sc\xe9nario|Plan du Sc\xe9nario|Plan Senaryo|Plan senaryo|Plang vum Szenario|Pozad\xed|Pozadie|Pozadina|Pr\xedklady|P\u0159\xedklady|Primer|Primeri|Primjeri|Przyk\u0142ady|Raamstsenaarium|Reckon it's like|Rerefons|Scen\xe1r|Sc\xe9n\xe1\u0159|Scenarie|Scenarij|Scenarijai|Scenarijaus \u0161ablonas|Scenariji|Scen\u0101rijs|Scen\u0101rijs p\u0113c parauga|Scenarijus|Scenario|Sc\xe9nario|Scenario Amlinellol|Scenario Outline|Scenario Template|Scenariomal|Scenariomall|Scenarios|Scenariu|Scenariusz|Scenaro|Schema dello scenario|Se \xf0e|Se the|Se \xfee|Senario|Senaryo Deskripsyon|Senaryo deskripsyon|Senaryo|Senaryo tasla\u011f\u0131|Shiver me timbers|Situ\u0101cija|Situai|Situasie Uiteensetting|Situasie|Skenario konsep|Skenario|Skica|Structura scenariu|Structur\u0103 scenariu|Struktura scenarija|Stsenaarium|Swa hwaer swa|Swa|Swa hw\xe6r swa|Szablon scenariusza|Szenario|Szenariogrundriss|Tapaukset|Tapaus|Tapausaihio|Taust|Tausta|Template Keadaan|Template Senario|Template Situai|The thing of it is|T\xecnh hu\u1ed1ng|Variantai|Voorbeelde|Voorbeelden|Wharrimean is|Yo-ho-ho|You'll wanna|Za\u0142o\u017cenia|\u03a0\u03b1\u03c1\u03b1\u03b4\u03b5\u03af\u03b3\u03bc\u03b1\u03c4\u03b1|\u03a0\u03b5\u03c1\u03b9\u03b3\u03c1\u03b1\u03c6\u03ae \u03a3\u03b5\u03bd\u03b1\u03c1\u03af\u03bf\u03c5|\u03a3\u03b5\u03bd\u03ac\u03c1\u03b9\u03b1|\u03a3\u03b5\u03bd\u03ac\u03c1\u03b9\u03bf|\u03a5\u03c0\u03cc\u03b2\u03b1\u03b8\u03c1\u03bf|\u041a\u0435\u0440\u0435\u0448|\u041a\u043e\u043d\u0442\u0435\u043a\u0441\u0442|\u041a\u043e\u043d\u0446\u0435\u043f\u0442|\u041c\u0438\u0441\u0430\u043b\u043b\u0430\u0440|\u041c\u0438\u0441\u043e\u043b\u043b\u0430\u0440|\u041e\u0441\u043d\u043e\u0432\u0430|\u041f\u0435\u0440\u0435\u0434\u0443\u043c\u043e\u0432\u0430|\u041f\u043e\u0437\u0430\u0434\u0438\u043d\u0430|\u041f\u0440\u0435\u0434\u0438\u0441\u0442\u043e\u0440\u0438\u044f|\u041f\u0440\u0435\u0434\u044b\u0441\u0442\u043e\u0440\u0438\u044f|\u041f\u0440\u0438\u043a\u043b\u0430\u0434\u0438|\u041f\u0440\u0438\u043c\u0435\u0440|\u041f\u0440\u0438\u043c\u0435\u0440\u0438|\u041f\u0440\u0438\u043c\u0435\u0440\u044b|\u0420\u0430\u043c\u043a\u0430 \u043d\u0430 \u0441\u0446\u0435\u043d\u0430\u0440\u0438\u0439|\u0421\u043a\u0438\u0446\u0430|\u0421\u0442\u0440\u0443\u043a\u0442\u0443\u0440\u0430 \u0441\u0446\u0435\u043d\u0430\u0440\u0438\u0458\u0430|\u0421\u0442\u0440\u0443\u043a\u0442\u0443\u0440\u0430 \u0441\u0446\u0435\u043d\u0430\u0440\u0438\u044f|\u0421\u0442\u0440\u0443\u043a\u0442\u0443\u0440\u0430 \u0441\u0446\u0435\u043d\u0430\u0440\u0456\u044e|\u0421\u0446\u0435\u043d\u0430\u0440\u0438\u0439|\u0421\u0446\u0435\u043d\u0430\u0440\u0438\u0439 \u0441\u0442\u0440\u0443\u043a\u0442\u0443\u0440\u0430\u0441\u0438|\u0421\u0446\u0435\u043d\u0430\u0440\u0438\u0439\u043d\u044b\u04a3 \u0442\u04e9\u0437\u0435\u043b\u0435\u0448\u0435|\u0421\u0446\u0435\u043d\u0430\u0440\u0438\u0458\u0438|\u0421\u0446\u0435\u043d\u0430\u0440\u0438\u043e|\u0421\u0446\u0435\u043d\u0430\u0440\u0456\u0439|\u0422\u0430\u0440\u0438\u0445|\u04ae\u0440\u043d\u04d9\u043a\u043b\u04d9\u0440|\u05d3\u05d5\u05d2\u05de\u05d0\u05d5\u05ea|\u05e8\u05e7\u05e2|\u05ea\u05d1\u05e0\u05d9\u05ea \u05ea\u05e8\u05d7\u05d9\u05e9|\u05ea\u05e8\u05d7\u05d9\u05e9|\u0627\u0644\u062e\u0644\u0641\u064a\u0629|\u0627\u0644\u06af\u0648\u06cc \u0633\u0646\u0627\u0631\u06cc\u0648|\u0627\u0645\u062b\u0644\u0629|\u067e\u0633 \u0645\u0646\u0638\u0631|\u0632\u0645\u06cc\u0646\u0647|\u0633\u0646\u0627\u0631\u06cc\u0648|\u0633\u064a\u0646\u0627\u0631\u064a\u0648|\u0633\u064a\u0646\u0627\u0631\u064a\u0648 \u0645\u062e\u0637\u0637|\u0645\u062b\u0627\u0644\u06cc\u06ba|\u0645\u0646\u0638\u0631 \u0646\u0627\u0645\u06d2 \u06a9\u0627 \u062e\u0627\u06a9\u06c1|\u0645\u0646\u0638\u0631\u0646\u0627\u0645\u06c1|\u0646\u0645\u0648\u0646\u0647 \u0647\u0627|\u0909\u0926\u093e\u0939\u0930\u0923|\u092a\u0930\u093f\u0926\u0943\u0936\u094d\u092f|\u092a\u0930\u093f\u0926\u0943\u0936\u094d\u092f \u0930\u0942\u092a\u0930\u0947\u0916\u093e|\u092a\u0943\u0937\u094d\u0920\u092d\u0942\u092e\u093f|\u0a09\u0a26\u0a3e\u0a39\u0a30\u0a28\u0a3e\u0a02|\u0a2a\u0a1f\u0a15\u0a25\u0a3e|\u0a2a\u0a1f\u0a15\u0a25\u0a3e \u0a22\u0a3e\u0a02\u0a1a\u0a3e|\u0a2a\u0a1f\u0a15\u0a25\u0a3e \u0a30\u0a42\u0a2a \u0a30\u0a47\u0a16\u0a3e|\u0a2a\u0a3f\u0a1b\u0a4b\u0a15\u0a5c|\u0c09\u0c26\u0c3e\u0c39\u0c30\u0c23\u0c32\u0c41|\u0c15\u0c25\u0c28\u0c02|\u0c28\u0c47\u0c2a\u0c25\u0c4d\u0c2f\u0c02|\u0c38\u0c28\u0c4d\u0c28\u0c3f\u0c35\u0c47\u0c36\u0c02|\u0c89\u0ca6\u0cbe\u0cb9\u0cb0\u0ca3\u0cc6\u0c97\u0cb3\u0cc1|\u0c95\u0ca5\u0cbe\u0cb8\u0cbe\u0cb0\u0cbe\u0c82\u0cb6|\u0cb5\u0cbf\u0cb5\u0cb0\u0ca3\u0cc6|\u0cb9\u0cbf\u0ca8\u0ccd\u0ca8\u0cc6\u0cb2\u0cc6|\u0e42\u0e04\u0e23\u0e07\u0e2a\u0e23\u0e49\u0e32\u0e07\u0e02\u0e2d\u0e07\u0e40\u0e2b\u0e15\u0e38\u0e01\u0e32\u0e23\u0e13\u0e4c|\u0e0a\u0e38\u0e14\u0e02\u0e2d\u0e07\u0e15\u0e31\u0e27\u0e2d\u0e22\u0e48\u0e32\u0e07|\u0e0a\u0e38\u0e14\u0e02\u0e2d\u0e07\u0e40\u0e2b\u0e15\u0e38\u0e01\u0e32\u0e23\u0e13\u0e4c|\u0e41\u0e19\u0e27\u0e04\u0e34\u0e14|\u0e2a\u0e23\u0e38\u0e1b\u0e40\u0e2b\u0e15\u0e38\u0e01\u0e32\u0e23\u0e13\u0e4c|\u0e40\u0e2b\u0e15\u0e38\u0e01\u0e32\u0e23\u0e13\u0e4c|\ubc30\uacbd|\uc2dc\ub098\ub9ac\uc624|\uc2dc\ub098\ub9ac\uc624 \uac1c\uc694|\uc608|\u30b5\u30f3\u30d7\u30eb|\u30b7\u30ca\u30ea\u30aa|\u30b7\u30ca\u30ea\u30aa\u30a2\u30a6\u30c8\u30e9\u30a4\u30f3|\u30b7\u30ca\u30ea\u30aa\u30c6\u30f3\u30d7\u30ec|\u30b7\u30ca\u30ea\u30aa\u30c6\u30f3\u30d7\u30ec\u30fc\u30c8|\u30c6\u30f3\u30d7\u30ec|\u4f8b|\u4f8b\u5b50|\u5267\u672c|\u5267\u672c\u5927\u7eb2|\u5287\u672c|\u5287\u672c\u5927\u7db1|\u573a\u666f|\u573a\u666f\u5927\u7eb2|\u5834\u666f|\u5834\u666f\u5927\u7db1|\u80cc\u666f):[^:\r\n]*/m,lookbehind:!0,inside:{important:{pattern:/(:)[^\r\n]*/,lookbehind:!0},keyword:/[^:\r\n]+:/}},"table-body":{pattern:RegExp("("+e+")(?:"+e+")+"),lookbehind:!0,inside:{outline:{pattern:/<[^>]+>/,alias:"variable"},td:{pattern:/\s*[^\s|][^|]*/,alias:"string"},punctuation:/\|/}},"table-head":{pattern:RegExp(e),inside:{th:{pattern:/\s*[^\s|][^|]*/,alias:"variable"},punctuation:/\|/}},atrule:{pattern:/(^[ \t]+)(?:'a|'ach|'ej|7|a|A tak\xe9|A taktie\u017e|A tie\u017e|A z\xe1rove\u0148|Aber|Ac|Adott|Akkor|Ak|Aleshores|Ale|Ali|Allora|Alors|Als|Ama|Amennyiben|Amikor|Ampak|an|AN|Ananging|And y'all|And|Angenommen|Anrhegedig a|An|Apabila|At\xe8s|Atesa|Atunci|Avast!|Aye|A|awer|Bagi|Banjur|Bet|Bi\u1ebft|Blimey!|Buh|But at the end of the day I reckon|But y'all|But|BUT|Cal|C\xe2nd|Cand|Cando|Ce|Cuando|\u010ce|\xd0a \xf0e|\xd0a|Dadas|Dada|Dados|Dado|DaH ghu' bejlu'|dann|Dann|Dano|Dan|Dar|Dat fiind|Data|Date fiind|Date|Dati fiind|Dati|Da\u0163i fiind|Da\u021bi fiind|DEN|Dato|De|Den youse gotta|Dengan|Diberi|Diyelim ki|Donada|Donat|Donita\u0135o|Do|Dun|Duota|\xd0urh|Eeldades|Ef|E\u011fer ki|Entao|Ent\xe3o|Ent\xf3n|E|En|Entonces|Epi|\xc9s|Etant donn\xe9e|Etant donn\xe9|Et|\xc9tant donn\xe9es|\xc9tant donn\xe9e|\xc9tant donn\xe9|Etant donn\xe9es|Etant donn\xe9s|\xc9tant donn\xe9s|Fakat|Gangway!|Gdy|Gegeben seien|Gegeben sei|Gegeven|Gegewe|ghu' noblu'|Gitt|Given y'all|Given|Givet|Givun|Ha|Cho|I CAN HAZ|In|Ir|It's just unbelievable|I|Ja|Je\u015bli|Je\u017celi|Kad|Kada|Kadar|Kai|Kaj|Kdy\u017e|Ke\u010f|Kemudian|Ketika|Khi|Kiedy|Ko|Kuid|Kui|Kun|Lan|latlh|Le sa a|Let go and haul|Le|L\xe8 sa a|L\xe8|Logo|Lorsqu'<|Lorsque|m\xe4|Maar|Mais|Maj\u0105c|Ma|Majd|Maka|Manawa|Mas|Men|Menawa|Mutta|Nalika|Nalikaning|Nanging|N\xe5r|N\xe4r|Nato|Nh\u01b0ng|Niin|Njuk|O zaman|Och|Og|Oletetaan|Ond|Onda|Oraz|Pak|Pero|Per\xf2|Podano|Pokia\u013e|Pokud|Potem|Potom|Privzeto|Pryd|Quan|Quand|Quando|qaSDI'|S\xe5|Sed|Se|Siis|Sipoze ke|Sipoze Ke|Sipoze|Si|\u015ei|\u0218i|Soit|Stel|Tada|Tad|Takrat|Tak|Tapi|Ter|Tetapi|Tha the|Tha|Then y'all|Then|Th\xec|Thurh|Toda|Too right|Un|Und|ugeholl|V\xe0|vaj|Vendar|Ve|wann|Wanneer|WEN|Wenn|When y'all|When|Wtedy|Wun|Y'know|Yeah nah|Yna|Youse know like when|Youse know when youse got|Y|Za predpokladu|Za p\u0159edpokladu|Zadan|Zadani|Zadano|Zadate|Zadato|Zak\u0142adaj\u0105c|Zaradi|Zatati|\xdea \xfee|\xdea|\xde\xe1|\xdeegar|\xdeurh|\u0391\u03bb\u03bb\u03ac|\u0394\u03b5\u03b4\u03bf\u03bc\u03ad\u03bd\u03bf\u03c5|\u039a\u03b1\u03b9|\u038c\u03c4\u03b1\u03bd|\u03a4\u03cc\u03c4\u03b5|\u0410 \u0442\u0430\u043a\u043e\u0436|\u0410\u0433\u0430\u0440|\u0410\u043b\u0435|\u0410\u043b\u0438|\u0410\u043c\u043c\u043e|\u0410|\u04d8\u0433\u04d9\u0440|\u04d8\u0439\u0442\u0438\u043a|\u04d8\u043c\u043c\u0430|\u0411\u0438\u0440\u043e\u043a|\u0412\u0430|\u0412\u04d9|\u0414\u0430\u0434\u0435\u043d\u043e|\u0414\u0430\u043d\u043e|\u0414\u043e\u043f\u0443\u0441\u0442\u0438\u043c|\u0415\u0441\u043b\u0438|\u0417\u0430\u0434\u0430\u0442\u0435|\u0417\u0430\u0434\u0430\u0442\u0438|\u0417\u0430\u0434\u0430\u0442\u043e|\u0418|\u0406|\u041a \u0442\u043e\u043c\u0443 \u0436\u0435|\u041a\u0430\u0434\u0430|\u041a\u0430\u0434|\u041a\u043e\u0433\u0430\u0442\u043e|\u041a\u043e\u0433\u0434\u0430|\u041a\u043e\u043b\u0438|\u041b\u04d9\u043a\u0438\u043d|\u041b\u0435\u043a\u0438\u043d|\u041d\u04d9\u0442\u0438\u0497\u04d9\u0434\u04d9|\u041d\u0435\u0445\u0430\u0439|\u041d\u043e|\u041e\u043d\u0434\u0430|\u041f\u0440\u0438\u043f\u0443\u0441\u0442\u0438\u043c\u043e, \u0449\u043e|\u041f\u0440\u0438\u043f\u0443\u0441\u0442\u0438\u043c\u043e|\u041f\u0443\u0441\u0442\u044c|\u0422\u0430\u043a\u0436\u0435|\u0422\u0430|\u0422\u043e\u0433\u0434\u0430|\u0422\u043e\u0434\u0456|\u0422\u043e|\u0423\u043d\u0434\u0430|\u04ba\u04d9\u043c|\u042f\u043a\u0449\u043e|\u05d0\u05d1\u05dc|\u05d0\u05d6\u05d9|\u05d0\u05d6|\u05d1\u05d4\u05d9\u05e0\u05ea\u05df|\u05d5\u05d2\u05dd|\u05db\u05d0\u05e9\u05e8|\u0622\u0646\u06af\u0627\u0647|\u0627\u0630\u0627\u064b|\u0627\u06af\u0631|\u0627\u0645\u0627|\u0627\u0648\u0631|\u0628\u0627 \u0641\u0631\u0636|\u0628\u0627\u0644\u0641\u0631\u0636|\u0628\u0641\u0631\u0636|\u067e\u06be\u0631|\u062a\u0628|\u062b\u0645|\u062c\u0628|\u0639\u0646\u062f\u0645\u0627|\u0641\u0631\u0636 \u06a9\u06cc\u0627|\u0644\u0643\u0646|\u0644\u06cc\u06a9\u0646|\u0645\u062a\u0649|\u0647\u0646\u06af\u0627\u0645\u06cc|\u0648|\u0905\u0917\u0930|\u0914\u0930|\u0915\u0926\u093e|\u0915\u093f\u0928\u094d\u0924\u0941|\u091a\u0942\u0902\u0915\u093f|\u091c\u092c|\u0924\u0925\u093e|\u0924\u0926\u093e|\u0924\u092c|\u092a\u0930\u0928\u094d\u0924\u0941|\u092a\u0930|\u092f\u0926\u093f|\u0a05\u0a24\u0a47|\u0a1c\u0a26\u0a4b\u0a02|\u0a1c\u0a3f\u0a35\u0a47\u0a02 \u0a15\u0a3f|\u0a1c\u0a47\u0a15\u0a30|\u0a24\u0a26|\u0a2a\u0a30|\u0c05\u0c2a\u0c4d\u0c2a\u0c41\u0c21\u0c41|\u0c08 \u0c2a\u0c30\u0c3f\u0c38\u0c4d\u0c25\u0c3f\u0c24\u0c3f\u0c32\u0c4b|\u0c15\u0c3e\u0c28\u0c3f|\u0c1a\u0c46\u0c2a\u0c4d\u0c2a\u0c2c\u0c21\u0c3f\u0c28\u0c26\u0c3f|\u0c2e\u0c30\u0c3f\u0c2f\u0c41|\u0c86\u0ca6\u0cb0\u0cc6|\u0ca8\u0c82\u0ca4\u0cb0|\u0ca8\u0cbf\u0cd5\u0ca1\u0cbf\u0ca6|\u0cae\u0ca4\u0ccd\u0ca4\u0cc1|\u0cb8\u0ccd\u0ca5\u0cbf\u0ca4\u0cbf\u0caf\u0ca8\u0ccd\u0ca8\u0cc1|\u0e01\u0e33\u0e2b\u0e19\u0e14\u0e43\u0e2b\u0e49|\u0e14\u0e31\u0e07\u0e19\u0e31\u0e49\u0e19|\u0e41\u0e15\u0e48|\u0e40\u0e21\u0e37\u0e48\u0e2d|\u0e41\u0e25\u0e30|\uadf8\ub7ec\uba74<|\uadf8\ub9ac\uace0<|\ub2e8<|\ub9cc\uc57d<|\ub9cc\uc77c<|\uba3c\uc800<|\uc870\uac74<|\ud558\uc9c0\ub9cc<|\u304b\u3064<|\u3057\u304b\u3057<|\u305f\u3060\u3057<|\u306a\u3089\u3070<|\u3082\u3057<|\u4e26\u4e14<|\u4f46\u3057<|\u4f46\u662f<|\u5047\u5982<|\u5047\u5b9a<|\u5047\u8a2d<|\u5047\u8bbe<|\u524d\u63d0<|\u540c\u65f6<|\u540c\u6642<|\u5e76\u4e14<|\u5f53<|\u7576<|\u800c\u4e14<|\u90a3\u4e48<|\u90a3\u9ebc<)(?=[ \t])/m,lookbehind:!0},string:{pattern:/"(?:\\.|[^"\\\r\n])*"|'(?:\\.|[^'\\\r\n])*'/,inside:{outline:{pattern:/<[^>]+>/,alias:"variable"}}},outline:{pattern:/<[^>]+>/,alias:"variable"}}}(a)}a.exports=e,e.displayName="gherkin",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/16038.8c61a9b6.chunk.js b/ydb/core/viewer/monitoring/static/js/16038.8c61a9b6.chunk.js new file mode 100644 index 000000000000..80fff40a3bfb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16038.8c61a9b6.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16038],{16038:(e,t,s)=>{s.d(t,{default:()=>n});var i=s(60483);const n=s.n(i)()},60483:e=>{function t(e){!function(e){var t={function:/\b(?:BUGS?|FIX(?:MES?)?|NOTES?|TODOS?|XX+|HACKS?|WARN(?:ING)?|\?{2,}|!{2,})\b/},s={number:/\\[^\s']|%\w/},i={comment:[{pattern:/(^|\s)(?:! .*|!$)/,lookbehind:!0,inside:t},{pattern:/(^|\s)\/\*\s[\s\S]*?\*\/(?=\s|$)/,lookbehind:!0,greedy:!0,inside:t},{pattern:/(^|\s)!\[(={0,6})\[\s[\s\S]*?\]\2\](?=\s|$)/,lookbehind:!0,greedy:!0,inside:t}],number:[{pattern:/(^|\s)[+-]?\d+(?=\s|$)/,lookbehind:!0},{pattern:/(^|\s)[+-]?0(?:b[01]+|o[0-7]+|d\d+|x[\dA-F]+)(?=\s|$)/i,lookbehind:!0},{pattern:/(^|\s)[+-]?\d+\/\d+\.?(?=\s|$)/,lookbehind:!0},{pattern:/(^|\s)\+?\d+\+\d+\/\d+(?=\s|$)/,lookbehind:!0},{pattern:/(^|\s)-\d+-\d+\/\d+(?=\s|$)/,lookbehind:!0},{pattern:/(^|\s)[+-]?(?:\d*\.\d+|\d+\.\d*|\d+)(?:e[+-]?\d+)?(?=\s|$)/i,lookbehind:!0},{pattern:/(^|\s)NAN:\s+[\da-fA-F]+(?=\s|$)/,lookbehind:!0},{pattern:/(^|\s)[+-]?0(?:b1\.[01]*|o1\.[0-7]*|d1\.\d*|x1\.[\dA-F]*)p\d+(?=\s|$)/i,lookbehind:!0}],regexp:{pattern:/(^|\s)R\/\s(?:\\\S|[^\\/])*\/(?:[idmsr]*|[idmsr]+-[idmsr]+)(?=\s|$)/,lookbehind:!0,alias:"number",inside:{variable:/\\\S/,keyword:/[+?*\[\]^$(){}.|]/,operator:{pattern:/(\/)[idmsr]+(?:-[idmsr]+)?/,lookbehind:!0}}},boolean:{pattern:/(^|\s)[tf](?=\s|$)/,lookbehind:!0},"custom-string":{pattern:/(^|\s)[A-Z0-9\-]+"\s(?:\\\S|[^"\\])*"/,lookbehind:!0,greedy:!0,alias:"string",inside:{number:/\\\S|%\w|\//}},"multiline-string":[{pattern:/(^|\s)STRING:\s+\S+(?:\n|\r\n).*(?:\n|\r\n)\s*;(?=\s|$)/,lookbehind:!0,greedy:!0,alias:"string",inside:{number:s.number,"semicolon-or-setlocal":{pattern:/([\r\n][ \t]*);(?=\s|$)/,lookbehind:!0,alias:"function"}}},{pattern:/(^|\s)HEREDOC:\s+\S+(?:\n|\r\n).*(?:\n|\r\n)\s*\S+(?=\s|$)/,lookbehind:!0,greedy:!0,alias:"string",inside:s},{pattern:/(^|\s)\[(={0,6})\[\s[\s\S]*?\]\2\](?=\s|$)/,lookbehind:!0,greedy:!0,alias:"string",inside:s}],"special-using":{pattern:/(^|\s)USING:(?:\s\S+)*(?=\s+;(?:\s|$))/,lookbehind:!0,alias:"function",inside:{string:{pattern:/(\s)[^:\s]+/,lookbehind:!0}}},"stack-effect-delimiter":[{pattern:/(^|\s)(?:call|eval|execute)?\((?=\s)/,lookbehind:!0,alias:"operator"},{pattern:/(\s)--(?=\s)/,lookbehind:!0,alias:"operator"},{pattern:/(\s)\)(?=\s|$)/,lookbehind:!0,alias:"operator"}],combinators:{pattern:null,lookbehind:!0,alias:"keyword"},"kernel-builtin":{pattern:null,lookbehind:!0,alias:"variable"},"sequences-builtin":{pattern:null,lookbehind:!0,alias:"variable"},"math-builtin":{pattern:null,lookbehind:!0,alias:"variable"},"constructor-word":{pattern:/(^|\s)<(?!=+>|-+>)\S+>(?=\s|$)/,lookbehind:!0,alias:"keyword"},"other-builtin-syntax":{pattern:null,lookbehind:!0,alias:"operator"},"conventionally-named-word":{pattern:/(^|\s)(?!")(?:(?:change|new|set|with)-\S+|\$\S+|>[^>\s]+|[^:>\s]+>|[^>\s]+>[^>\s]+|\+[^+\s]+\+|[^?\s]+\?|\?[^?\s]+|[^>\s]+>>|>>[^>\s]+|[^<\s]+<<|\([^()\s]+\)|[^!\s]+!|[^*\s]\S*\*|[^.\s]\S*\.)(?=\s|$)/,lookbehind:!0,alias:"keyword"},"colon-syntax":{pattern:/(^|\s)(?:[A-Z0-9\-]+#?)?:{1,2}\s+(?:;\S+|(?!;)\S+)(?=\s|$)/,lookbehind:!0,greedy:!0,alias:"function"},"semicolon-or-setlocal":{pattern:/(\s)(?:;|:>)(?=\s|$)/,lookbehind:!0,alias:"function"},"curly-brace-literal-delimiter":[{pattern:/(^|\s)[a-z]*\{(?=\s)/i,lookbehind:!0,alias:"operator"},{pattern:/(\s)\}(?=\s|$)/,lookbehind:!0,alias:"operator"}],"quotation-delimiter":[{pattern:/(^|\s)\[(?=\s)/,lookbehind:!0,alias:"operator"},{pattern:/(\s)\](?=\s|$)/,lookbehind:!0,alias:"operator"}],"normal-word":{pattern:/(^|\s)[^"\s]\S*(?=\s|$)/,lookbehind:!0},string:{pattern:/"(?:\\\S|[^"\\])*"/,greedy:!0,inside:s}},n=function(e){return(e+"").replace(/([.?*+\^$\[\]\\(){}|\-])/g,"\\$1")},r=function(e){return new RegExp("(^|\\s)(?:"+e.map(n).join("|")+")(?=\\s|$)")},a={"kernel-builtin":["or","2nipd","4drop","tuck","wrapper","nip","wrapper?","callstack>array","die","dupd","callstack","callstack?","3dup","hashcode","pick","4nip","build",">boolean","nipd","clone","5nip","eq?","?","=","swapd","2over","clear","2dup","get-retainstack","not","tuple?","dup","3nipd","call","-rotd","object","drop","assert=","assert?","-rot","execute","boa","get-callstack","curried?","3drop","pickd","overd","over","roll","3nip","swap","and","2nip","rotd","throw","(clone)","hashcode*","spin","reach","4dup","equal?","get-datastack","assert","2drop","","boolean?","identity-hashcode","identity-tuple?","null","composed?","new","5drop","rot","-roll","xor","identity-tuple","boolean"],"other-builtin-syntax":["=======","recursive","flushable",">>","<<<<<<","M\\","B","PRIVATE>","\\","======","final","inline","delimiter","deprecated",">>>>>","<<<<<<<","parse-complex","malformed-complex","read-only",">>>>>>>","call-next-method","<<","foldable","$","$[","${"],"sequences-builtin":["member-eq?","mismatch","append","assert-sequence=","longer","repetition","clone-like","3sequence","assert-sequence?","last-index-from","reversed","index-from","cut*","pad-tail","join-as","remove-eq!","concat-as","but-last","snip","nths","nth","sequence","longest","slice?","","remove-nth","tail-slice","empty?","tail*","member?","virtual-sequence?","set-length","drop-prefix","iota","unclip","bounds-error?","unclip-last-slice","non-negative-integer-expected","non-negative-integer-expected?","midpoint@","longer?","?set-nth","?first","rest-slice","prepend-as","prepend","fourth","sift","subseq-start","new-sequence","?last","like","first4","1sequence","reverse","slice","virtual@","repetition?","set-last","index","4sequence","max-length","set-second","immutable-sequence","first2","first3","supremum","unclip-slice","suffix!","insert-nth","tail","3append","short","suffix","concat","flip","immutable?","reverse!","2sequence","sum","delete-all","indices","snip-slice","","check-slice","sequence?","head","append-as","halves","sequence=","collapse-slice","?second","slice-error?","product","bounds-check?","bounds-check","immutable","virtual-exemplar","harvest","remove","pad-head","last","set-fourth","cartesian-product","remove-eq","shorten","shorter","reversed?","shorter?","shortest","head-slice","pop*","tail-slice*","but-last-slice","iota?","append!","cut-slice","new-resizable","head-slice*","sequence-hashcode","pop","set-nth","?nth","second","join","immutable-sequence?","","3append-as","virtual-sequence","subseq?","remove-nth!","length","last-index","lengthen","assert-sequence","copy","move","third","first","tail?","set-first","prefix","bounds-error","","exchange","surround","cut","min-length","set-third","push-all","head?","subseq-start-from","delete-slice","rest","sum-lengths","head*","infimum","remove!","glue","slice-error","subseq","push","replace-slice","subseq-as","unclip-last"],"math-builtin":["number=","next-power-of-2","?1+","fp-special?","imaginary-part","float>bits","number?","fp-infinity?","bignum?","fp-snan?","denominator","gcd","*","+","fp-bitwise=","-","u>=","/",">=","bitand","power-of-2?","log2-expects-positive","neg?","<","log2",">","integer?","number","bits>double","2/","zero?","bits>float","float?","shift","ratio?","rect>","even?","ratio","fp-sign","bitnot",">fixnum","complex?","/i","integer>fixnum","/f","sgn",">bignum","next-float","u<","u>","mod","recip","rational",">float","2^","integer","fixnum?","neg","fixnum","sq","bignum",">rect","bit?","fp-qnan?","simple-gcd","complex","","real",">fraction","double>bits","bitor","rem","fp-nan-payload","real-part","log2-expects-positive?","prev-float","align","unordered?","float","fp-nan?","abs","bitxor","integer>fixnum-strict","u<=","odd?","<=","/mod",">integer","real?","rational?","numerator"]};Object.keys(a).forEach((function(e){i[e].pattern=r(a[e])}));i.combinators.pattern=r(["2bi","while","2tri","bi*","4dip","both?","same?","tri@","curry","prepose","3bi","?if","tri*","2keep","3keep","curried","2keepd","when","2bi*","2tri*","4keep","bi@","keepdd","do","unless*","tri-curry","if*","loop","bi-curry*","when*","2bi@","2tri@","with","2with","either?","bi","until","3dip","3curry","tri-curry*","tri-curry@","bi-curry","keepd","compose","2dip","if","3tri","unless","tuple","keep","2curry","tri","most","while*","dip","composed","bi-curry@","find-last-from","trim-head-slice","map-as","each-from","none?","trim-tail","partition","if-empty","accumulate*","reject!","find-from","accumulate-as","collector-for-as","reject","map","map-sum","accumulate!","2each-from","follow","supremum-by","map!","unless-empty","collector","padding","reduce-index","replicate-as","infimum-by","trim-tail-slice","count","find-index","filter","accumulate*!","reject-as","map-integers","map-find","reduce","selector","interleave","2map","filter-as","binary-reduce","map-index-as","find","produce","filter!","replicate","cartesian-map","cartesian-each","find-index-from","map-find-last","3map-as","3map","find-last","selector-as","2map-as","2map-reduce","accumulate","each","each-index","accumulate*-as","when-empty","all?","collector-as","push-either","new-like","collector-for","2selector","push-if","2all?","map-reduce","3each","any?","trim-slice","2reduce","change-nth","produce-as","2each","trim","trim-head","cartesian-find","map-index","if-zero","each-integer","unless-zero","(find-integer)","when-zero","find-last-integer","(all-integers?)","times","(each-integer)","find-integer","all-integers?","unless-negative","if-positive","when-positive","when-negative","unless-positive","if-negative","case","2cleave","cond>quot","case>quot","3cleave","wrong-values","to-fixed-point","alist>quot","cond","cleave","call-effect","recursive-hashcode","spread","deep-spread>quot","2||","0||","n||","0&&","2&&","3||","1||","1&&","n&&","3&&","smart-unless*","keep-inputs","reduce-outputs","smart-when*","cleave>array","smart-with","smart-apply","smart-if","inputs/outputs","output>sequence-n","map-outputs","map-reduce-outputs","dropping","output>array","smart-map-reduce","smart-2map-reduce","output>array-n","nullary","inputsequence"]),e.languages.factor=i}(e)}e.exports=t,t.displayName="factor",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/16097.4303c083.chunk.js b/ydb/core/viewer/monitoring/static/js/16097.4303c083.chunk.js new file mode 100644 index 000000000000..3849049c1f60 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16097.4303c083.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16097],{16097:(e,a,t)=>{t.d(a,{default:()=>n});var i=t(89244);const n=t.n(i)()},89244:(e,a,t)=>{var i=t(89343);function n(e){e.register(i),e.languages.glsl=e.languages.extend("c",{keyword:/\b(?:active|asm|atomic_uint|attribute|[ibdu]?vec[234]|bool|break|buffer|case|cast|centroid|class|coherent|common|const|continue|d?mat[234](?:x[234])?|default|discard|do|double|else|enum|extern|external|false|filter|fixed|flat|float|for|fvec[234]|goto|half|highp|hvec[234]|[iu]?sampler2DMS(?:Array)?|[iu]?sampler2DRect|[iu]?samplerBuffer|[iu]?samplerCube|[iu]?samplerCubeArray|[iu]?sampler[123]D|[iu]?sampler[12]DArray|[iu]?image2DMS(?:Array)?|[iu]?image2DRect|[iu]?imageBuffer|[iu]?imageCube|[iu]?imageCubeArray|[iu]?image[123]D|[iu]?image[12]DArray|if|in|inline|inout|input|int|interface|invariant|layout|long|lowp|mediump|namespace|noinline|noperspective|out|output|partition|patch|precise|precision|public|readonly|resource|restrict|return|sample|sampler[12]DArrayShadow|sampler[12]DShadow|sampler2DRectShadow|sampler3DRect|samplerCubeArrayShadow|samplerCubeShadow|shared|short|sizeof|smooth|static|struct|subroutine|superp|switch|template|this|true|typedef|uint|uniform|union|unsigned|using|varying|void|volatile|while|writeonly)\b/})}e.exports=n,n.displayName="glsl",n.aliases=[]},89343:e=>{function a(e){e.languages.c=e.languages.extend("clike",{comment:{pattern:/\/\/(?:[^\r\n\\]|\\(?:\r\n?|\n|(?![\r\n])))*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"class-name":{pattern:/(\b(?:enum|struct)\s+(?:__attribute__\s*\(\([\s\S]*?\)\)\s*)?)\w+|\b[a-z]\w*_t\b/,lookbehind:!0},keyword:/\b(?:_Alignas|_Alignof|_Atomic|_Bool|_Complex|_Generic|_Imaginary|_Noreturn|_Static_assert|_Thread_local|__attribute__|asm|auto|break|case|char|const|continue|default|do|double|else|enum|extern|float|for|goto|if|inline|int|long|register|return|short|signed|sizeof|static|struct|switch|typedef|typeof|union|unsigned|void|volatile|while)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ful]{0,4}/i,operator:/>>=?|<<=?|->|([-+&|:])\1|[?:~]|[-+*/%&|^!=<>]=?/}),e.languages.insertBefore("c","string",{char:{pattern:/'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n]){0,32}'/,greedy:!0}}),e.languages.insertBefore("c","string",{macro:{pattern:/(^[\t ]*)#\s*[a-z](?:[^\r\n\\/]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{string:[{pattern:/^(#\s*include\s*)<[^>]+>/,lookbehind:!0},e.languages.c.string],char:e.languages.c.char,comment:e.languages.c.comment,"macro-name":[{pattern:/(^#\s*define\s+)\w+\b(?!\()/i,lookbehind:!0},{pattern:/(^#\s*define\s+)\w+\b(?=\()/i,lookbehind:!0,alias:"function"}],directive:{pattern:/^(#\s*)[a-z]+/,lookbehind:!0,alias:"keyword"},"directive-hash":/^#/,punctuation:/##|\\(?=[\r\n])/,expression:{pattern:/\S[\s\S]*/,inside:e.languages.c}}}}),e.languages.insertBefore("c","function",{constant:/\b(?:EOF|NULL|SEEK_CUR|SEEK_END|SEEK_SET|__DATE__|__FILE__|__LINE__|__TIMESTAMP__|__TIME__|__func__|stderr|stdin|stdout)\b/}),delete e.languages.c.boolean}e.exports=a,a.displayName="c",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/16210.cfacbd9b.chunk.js b/ydb/core/viewer/monitoring/static/js/16210.cfacbd9b.chunk.js new file mode 100644 index 000000000000..7f4aac09eeb4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16210.cfacbd9b.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 16210.cfacbd9b.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16210],{93829:(E,T,S)=>{S.r(T),S.d(T,{conf:()=>R,language:()=>_});var R={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},_={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ACCESSIBLE","ADD","ALL","ALTER","ANALYZE","AND","AS","ASC","ASENSITIVE","BEFORE","BETWEEN","BIGINT","BINARY","BLOB","BOTH","BY","CALL","CASCADE","CASE","CHANGE","CHAR","CHARACTER","CHECK","COLLATE","COLUMN","CONDITION","CONSTRAINT","CONTINUE","CONVERT","CREATE","CROSS","CUBE","CUME_DIST","CURRENT_DATE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURSOR","DATABASE","DATABASES","DAY_HOUR","DAY_MICROSECOND","DAY_MINUTE","DAY_SECOND","DEC","DECIMAL","DECLARE","DEFAULT","DELAYED","DELETE","DENSE_RANK","DESC","DESCRIBE","DETERMINISTIC","DISTINCT","DISTINCTROW","DIV","DOUBLE","DROP","DUAL","EACH","ELSE","ELSEIF","EMPTY","ENCLOSED","ESCAPED","EXCEPT","EXISTS","EXIT","EXPLAIN","FALSE","FETCH","FIRST_VALUE","FLOAT","FLOAT4","FLOAT8","FOR","FORCE","FOREIGN","FROM","FULLTEXT","FUNCTION","GENERATED","GET","GRANT","GROUP","GROUPING","GROUPS","HAVING","HIGH_PRIORITY","HOUR_MICROSECOND","HOUR_MINUTE","HOUR_SECOND","IF","IGNORE","IN","INDEX","INFILE","INNER","INOUT","INSENSITIVE","INSERT","INT","INT1","INT2","INT3","INT4","INT8","INTEGER","INTERVAL","INTO","IO_AFTER_GTIDS","IO_BEFORE_GTIDS","IS","ITERATE","JOIN","JSON_TABLE","KEY","KEYS","KILL","LAG","LAST_VALUE","LATERAL","LEAD","LEADING","LEAVE","LEFT","LIKE","LIMIT","LINEAR","LINES","LOAD","LOCALTIME","LOCALTIMESTAMP","LOCK","LONG","LONGBLOB","LONGTEXT","LOOP","LOW_PRIORITY","MASTER_BIND","MASTER_SSL_VERIFY_SERVER_CERT","MATCH","MAXVALUE","MEDIUMBLOB","MEDIUMINT","MEDIUMTEXT","MIDDLEINT","MINUTE_MICROSECOND","MINUTE_SECOND","MOD","MODIFIES","NATURAL","NOT","NO_WRITE_TO_BINLOG","NTH_VALUE","NTILE","NULL","NUMERIC","OF","ON","OPTIMIZE","OPTIMIZER_COSTS","OPTION","OPTIONALLY","OR","ORDER","OUT","OUTER","OUTFILE","OVER","PARTITION","PERCENT_RANK","PRECISION","PRIMARY","PROCEDURE","PURGE","RANGE","RANK","READ","READS","READ_WRITE","REAL","RECURSIVE","REFERENCES","REGEXP","RELEASE","RENAME","REPEAT","REPLACE","REQUIRE","RESIGNAL","RESTRICT","RETURN","REVOKE","RIGHT","RLIKE","ROW","ROWS","ROW_NUMBER","SCHEMA","SCHEMAS","SECOND_MICROSECOND","SELECT","SENSITIVE","SEPARATOR","SET","SHOW","SIGNAL","SMALLINT","SPATIAL","SPECIFIC","SQL","SQLEXCEPTION","SQLSTATE","SQLWARNING","SQL_BIG_RESULT","SQL_CALC_FOUND_ROWS","SQL_SMALL_RESULT","SSL","STARTING","STORED","STRAIGHT_JOIN","SYSTEM","TABLE","TERMINATED","THEN","TINYBLOB","TINYINT","TINYTEXT","TO","TRAILING","TRIGGER","TRUE","UNDO","UNION","UNIQUE","UNLOCK","UNSIGNED","UPDATE","USAGE","USE","USING","UTC_DATE","UTC_TIME","UTC_TIMESTAMP","VALUES","VARBINARY","VARCHAR","VARCHARACTER","VARYING","VIRTUAL","WHEN","WHERE","WHILE","WINDOW","WITH","WRITE","XOR","YEAR_MONTH","ZEROFILL"],operators:["AND","BETWEEN","IN","LIKE","NOT","OR","IS","NULL","INTERSECT","UNION","INNER","JOIN","LEFT","OUTER","RIGHT"],builtinFunctions:["ABS","ACOS","ADDDATE","ADDTIME","AES_DECRYPT","AES_ENCRYPT","ANY_VALUE","Area","AsBinary","AsWKB","ASCII","ASIN","AsText","AsWKT","ASYMMETRIC_DECRYPT","ASYMMETRIC_DERIVE","ASYMMETRIC_ENCRYPT","ASYMMETRIC_SIGN","ASYMMETRIC_VERIFY","ATAN","ATAN2","ATAN","AVG","BENCHMARK","BIN","BIT_AND","BIT_COUNT","BIT_LENGTH","BIT_OR","BIT_XOR","Buffer","CAST","CEIL","CEILING","Centroid","CHAR","CHAR_LENGTH","CHARACTER_LENGTH","CHARSET","COALESCE","COERCIBILITY","COLLATION","COMPRESS","CONCAT","CONCAT_WS","CONNECTION_ID","Contains","CONV","CONVERT","CONVERT_TZ","ConvexHull","COS","COT","COUNT","CRC32","CREATE_ASYMMETRIC_PRIV_KEY","CREATE_ASYMMETRIC_PUB_KEY","CREATE_DH_PARAMETERS","CREATE_DIGEST","Crosses","CUME_DIST","CURDATE","CURRENT_DATE","CURRENT_ROLE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURTIME","DATABASE","DATE","DATE_ADD","DATE_FORMAT","DATE_SUB","DATEDIFF","DAY","DAYNAME","DAYOFMONTH","DAYOFWEEK","DAYOFYEAR","DECODE","DEFAULT","DEGREES","DES_DECRYPT","DES_ENCRYPT","DENSE_RANK","Dimension","Disjoint","Distance","ELT","ENCODE","ENCRYPT","EndPoint","Envelope","Equals","EXP","EXPORT_SET","ExteriorRing","EXTRACT","ExtractValue","FIELD","FIND_IN_SET","FIRST_VALUE","FLOOR","FORMAT","FORMAT_BYTES","FORMAT_PICO_TIME","FOUND_ROWS","FROM_BASE64","FROM_DAYS","FROM_UNIXTIME","GEN_RANGE","GEN_RND_EMAIL","GEN_RND_PAN","GEN_RND_SSN","GEN_RND_US_PHONE","GeomCollection","GeomCollFromText","GeometryCollectionFromText","GeomCollFromWKB","GeometryCollectionFromWKB","GeometryCollection","GeometryN","GeometryType","GeomFromText","GeometryFromText","GeomFromWKB","GeometryFromWKB","GET_FORMAT","GET_LOCK","GLength","GREATEST","GROUP_CONCAT","GROUPING","GTID_SUBSET","GTID_SUBTRACT","HEX","HOUR","ICU_VERSION","IF","IFNULL","INET_ATON","INET_NTOA","INET6_ATON","INET6_NTOA","INSERT","INSTR","InteriorRingN","Intersects","INTERVAL","IS_FREE_LOCK","IS_IPV4","IS_IPV4_COMPAT","IS_IPV4_MAPPED","IS_IPV6","IS_USED_LOCK","IS_UUID","IsClosed","IsEmpty","ISNULL","IsSimple","JSON_APPEND","JSON_ARRAY","JSON_ARRAY_APPEND","JSON_ARRAY_INSERT","JSON_ARRAYAGG","JSON_CONTAINS","JSON_CONTAINS_PATH","JSON_DEPTH","JSON_EXTRACT","JSON_INSERT","JSON_KEYS","JSON_LENGTH","JSON_MERGE","JSON_MERGE_PATCH","JSON_MERGE_PRESERVE","JSON_OBJECT","JSON_OBJECTAGG","JSON_OVERLAPS","JSON_PRETTY","JSON_QUOTE","JSON_REMOVE","JSON_REPLACE","JSON_SCHEMA_VALID","JSON_SCHEMA_VALIDATION_REPORT","JSON_SEARCH","JSON_SET","JSON_STORAGE_FREE","JSON_STORAGE_SIZE","JSON_TABLE","JSON_TYPE","JSON_UNQUOTE","JSON_VALID","LAG","LAST_DAY","LAST_INSERT_ID","LAST_VALUE","LCASE","LEAD","LEAST","LEFT","LENGTH","LineFromText","LineStringFromText","LineFromWKB","LineStringFromWKB","LineString","LN","LOAD_FILE","LOCALTIME","LOCALTIMESTAMP","LOCATE","LOG","LOG10","LOG2","LOWER","LPAD","LTRIM","MAKE_SET","MAKEDATE","MAKETIME","MASK_INNER","MASK_OUTER","MASK_PAN","MASK_PAN_RELAXED","MASK_SSN","MASTER_POS_WAIT","MAX","MBRContains","MBRCoveredBy","MBRCovers","MBRDisjoint","MBREqual","MBREquals","MBRIntersects","MBROverlaps","MBRTouches","MBRWithin","MD5","MEMBER OF","MICROSECOND","MID","MIN","MINUTE","MLineFromText","MultiLineStringFromText","MLineFromWKB","MultiLineStringFromWKB","MOD","MONTH","MONTHNAME","MPointFromText","MultiPointFromText","MPointFromWKB","MultiPointFromWKB","MPolyFromText","MultiPolygonFromText","MPolyFromWKB","MultiPolygonFromWKB","MultiLineString","MultiPoint","MultiPolygon","NAME_CONST","NOT IN","NOW","NTH_VALUE","NTILE","NULLIF","NumGeometries","NumInteriorRings","NumPoints","OCT","OCTET_LENGTH","OLD_PASSWORD","ORD","Overlaps","PASSWORD","PERCENT_RANK","PERIOD_ADD","PERIOD_DIFF","PI","Point","PointFromText","PointFromWKB","PointN","PolyFromText","PolygonFromText","PolyFromWKB","PolygonFromWKB","Polygon","POSITION","POW","POWER","PS_CURRENT_THREAD_ID","PS_THREAD_ID","PROCEDURE ANALYSE","QUARTER","QUOTE","RADIANS","RAND","RANDOM_BYTES","RANK","REGEXP_INSTR","REGEXP_LIKE","REGEXP_REPLACE","REGEXP_REPLACE","RELEASE_ALL_LOCKS","RELEASE_LOCK","REPEAT","REPLACE","REVERSE","RIGHT","ROLES_GRAPHML","ROUND","ROW_COUNT","ROW_NUMBER","RPAD","RTRIM","SCHEMA","SEC_TO_TIME","SECOND","SESSION_USER","SHA1","SHA","SHA2","SIGN","SIN","SLEEP","SOUNDEX","SOURCE_POS_WAIT","SPACE","SQRT","SRID","ST_Area","ST_AsBinary","ST_AsWKB","ST_AsGeoJSON","ST_AsText","ST_AsWKT","ST_Buffer","ST_Buffer_Strategy","ST_Centroid","ST_Collect","ST_Contains","ST_ConvexHull","ST_Crosses","ST_Difference","ST_Dimension","ST_Disjoint","ST_Distance","ST_Distance_Sphere","ST_EndPoint","ST_Envelope","ST_Equals","ST_ExteriorRing","ST_FrechetDistance","ST_GeoHash","ST_GeomCollFromText","ST_GeometryCollectionFromText","ST_GeomCollFromTxt","ST_GeomCollFromWKB","ST_GeometryCollectionFromWKB","ST_GeometryN","ST_GeometryType","ST_GeomFromGeoJSON","ST_GeomFromText","ST_GeometryFromText","ST_GeomFromWKB","ST_GeometryFromWKB","ST_HausdorffDistance","ST_InteriorRingN","ST_Intersection","ST_Intersects","ST_IsClosed","ST_IsEmpty","ST_IsSimple","ST_IsValid","ST_LatFromGeoHash","ST_Length","ST_LineFromText","ST_LineStringFromText","ST_LineFromWKB","ST_LineStringFromWKB","ST_LineInterpolatePoint","ST_LineInterpolatePoints","ST_LongFromGeoHash","ST_Longitude","ST_MakeEnvelope","ST_MLineFromText","ST_MultiLineStringFromText","ST_MLineFromWKB","ST_MultiLineStringFromWKB","ST_MPointFromText","ST_MultiPointFromText","ST_MPointFromWKB","ST_MultiPointFromWKB","ST_MPolyFromText","ST_MultiPolygonFromText","ST_MPolyFromWKB","ST_MultiPolygonFromWKB","ST_NumGeometries","ST_NumInteriorRing","ST_NumInteriorRings","ST_NumPoints","ST_Overlaps","ST_PointAtDistance","ST_PointFromGeoHash","ST_PointFromText","ST_PointFromWKB","ST_PointN","ST_PolyFromText","ST_PolygonFromText","ST_PolyFromWKB","ST_PolygonFromWKB","ST_Simplify","ST_SRID","ST_StartPoint","ST_SwapXY","ST_SymDifference","ST_Touches","ST_Transform","ST_Union","ST_Validate","ST_Within","ST_X","ST_Y","StartPoint","STATEMENT_DIGEST","STATEMENT_DIGEST_TEXT","STD","STDDEV","STDDEV_POP","STDDEV_SAMP","STR_TO_DATE","STRCMP","SUBDATE","SUBSTR","SUBSTRING","SUBSTRING_INDEX","SUBTIME","SUM","SYSDATE","SYSTEM_USER","TAN","TIME","TIME_FORMAT","TIME_TO_SEC","TIMEDIFF","TIMESTAMP","TIMESTAMPADD","TIMESTAMPDIFF","TO_BASE64","TO_DAYS","TO_SECONDS","Touches","TRIM","TRUNCATE","UCASE","UNCOMPRESS","UNCOMPRESSED_LENGTH","UNHEX","UNIX_TIMESTAMP","UpdateXML","UPPER","USER","UTC_DATE","UTC_TIME","UTC_TIMESTAMP","UUID","UUID_SHORT","UUID_TO_BIN","VALIDATE_PASSWORD_STRENGTH","VALUES","VAR_POP","VAR_SAMP","VARIANCE","VERSION","WAIT_FOR_EXECUTED_GTID_SET","WAIT_UNTIL_SQL_THREAD_AFTER_GTIDS","WEEK","WEEKDAY","WEEKOFYEAR","WEIGHT_STRING","Within","X","Y","YEAR","YEARWEEK"],builtinVariables:[],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@]+/,{cases:{"@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@keywords":"keyword","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/#+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}],[/"/,{token:"string.double",next:"@stringDouble"}]],string:[[/\\'/,"string"],[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],stringDouble:[[/[^"]+/,"string.double"],[/""/,"string.double"],[/"/,{token:"string.double",next:"@pop"}]],complexIdentifiers:[[/`/,{token:"identifier.quote",next:"@quotedIdentifier"}]],quotedIdentifier:[[/[^`]+/,"identifier"],[/``/,"identifier"],[/`/,{token:"identifier.quote",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1414.4cfda0bc.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/16210.cfacbd9b.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/1414.4cfda0bc.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/16210.cfacbd9b.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/16242.ba0392be.chunk.js b/ydb/core/viewer/monitoring/static/js/16242.ba0392be.chunk.js new file mode 100644 index 000000000000..48a0a4731e9b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16242.ba0392be.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16242],{16242:(d,e,b)=>{b.d(e,{default:()=>a});var u=b(61993);const a=b.n(u)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1627.80c94ebf.chunk.js b/ydb/core/viewer/monitoring/static/js/1627.80c94ebf.chunk.js deleted file mode 100644 index 18255db4112d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1627.80c94ebf.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1627],{51627:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),t={name:"en-nz",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){var _=["th","st","nd","rd"],a=e%100;return"["+e+(_[(a-20)%10]||_[a]||_[0])+"]"},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(t,null,!0),t}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1657.d6f0b340.chunk.js b/ydb/core/viewer/monitoring/static/js/1657.d6f0b340.chunk.js deleted file mode 100644 index 3f58e37f62de..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1657.d6f0b340.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1657],{21657:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"zh-cn",weekdays:"\u661f\u671f\u65e5_\u661f\u671f\u4e00_\u661f\u671f\u4e8c_\u661f\u671f\u4e09_\u661f\u671f\u56db_\u661f\u671f\u4e94_\u661f\u671f\u516d".split("_"),weekdaysShort:"\u5468\u65e5_\u5468\u4e00_\u5468\u4e8c_\u5468\u4e09_\u5468\u56db_\u5468\u4e94_\u5468\u516d".split("_"),weekdaysMin:"\u65e5_\u4e00_\u4e8c_\u4e09_\u56db_\u4e94_\u516d".split("_"),months:"\u4e00\u6708_\u4e8c\u6708_\u4e09\u6708_\u56db\u6708_\u4e94\u6708_\u516d\u6708_\u4e03\u6708_\u516b\u6708_\u4e5d\u6708_\u5341\u6708_\u5341\u4e00\u6708_\u5341\u4e8c\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),ordinal:function(_,e){return"W"===e?_+"\u5468":_+"\u65e5"},weekStart:1,yearStart:4,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5Ah\u70b9mm\u5206",LLLL:"YYYY\u5e74M\u6708D\u65e5ddddAh\u70b9mm\u5206",l:"YYYY/M/D",ll:"YYYY\u5e74M\u6708D\u65e5",lll:"YYYY\u5e74M\u6708D\u65e5 HH:mm",llll:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm"},relativeTime:{future:"%s\u5185",past:"%s\u524d",s:"\u51e0\u79d2",m:"1 \u5206\u949f",mm:"%d \u5206\u949f",h:"1 \u5c0f\u65f6",hh:"%d \u5c0f\u65f6",d:"1 \u5929",dd:"%d \u5929",M:"1 \u4e2a\u6708",MM:"%d \u4e2a\u6708",y:"1 \u5e74",yy:"%d \u5e74"},meridiem:function(_,e){var t=100*_+e;return t<600?"\u51cc\u6668":t<900?"\u65e9\u4e0a":t<1100?"\u4e0a\u5348":t<1300?"\u4e2d\u5348":t<1800?"\u4e0b\u5348":"\u665a\u4e0a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/16664.195e9acf.chunk.js b/ydb/core/viewer/monitoring/static/js/16664.195e9acf.chunk.js new file mode 100644 index 000000000000..043f367ad66c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16664.195e9acf.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16664],{16664:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ml",weekdays:"\u0d1e\u0d3e\u0d2f\u0d31\u0d3e\u0d34\u0d4d\u0d1a_\u0d24\u0d3f\u0d19\u0d4d\u0d15\u0d33\u0d3e\u0d34\u0d4d\u0d1a_\u0d1a\u0d4a\u0d35\u0d4d\u0d35\u0d3e\u0d34\u0d4d\u0d1a_\u0d2c\u0d41\u0d27\u0d28\u0d3e\u0d34\u0d4d\u0d1a_\u0d35\u0d4d\u0d2f\u0d3e\u0d34\u0d3e\u0d34\u0d4d\u0d1a_\u0d35\u0d46\u0d33\u0d4d\u0d33\u0d3f\u0d2f\u0d3e\u0d34\u0d4d\u0d1a_\u0d36\u0d28\u0d3f\u0d2f\u0d3e\u0d34\u0d4d\u0d1a".split("_"),months:"\u0d1c\u0d28\u0d41\u0d35\u0d30\u0d3f_\u0d2b\u0d46\u0d2c\u0d4d\u0d30\u0d41\u0d35\u0d30\u0d3f_\u0d2e\u0d3e\u0d7c\u0d1a\u0d4d\u0d1a\u0d4d_\u0d0f\u0d2a\u0d4d\u0d30\u0d3f\u0d7d_\u0d2e\u0d47\u0d2f\u0d4d_\u0d1c\u0d42\u0d7a_\u0d1c\u0d42\u0d32\u0d48_\u0d13\u0d17\u0d38\u0d4d\u0d31\u0d4d\u0d31\u0d4d_\u0d38\u0d46\u0d2a\u0d4d\u0d31\u0d4d\u0d31\u0d02\u0d2c\u0d7c_\u0d12\u0d15\u0d4d\u0d1f\u0d4b\u0d2c\u0d7c_\u0d28\u0d35\u0d02\u0d2c\u0d7c_\u0d21\u0d3f\u0d38\u0d02\u0d2c\u0d7c".split("_"),weekdaysShort:"\u0d1e\u0d3e\u0d2f\u0d7c_\u0d24\u0d3f\u0d19\u0d4d\u0d15\u0d7e_\u0d1a\u0d4a\u0d35\u0d4d\u0d35_\u0d2c\u0d41\u0d27\u0d7b_\u0d35\u0d4d\u0d2f\u0d3e\u0d34\u0d02_\u0d35\u0d46\u0d33\u0d4d\u0d33\u0d3f_\u0d36\u0d28\u0d3f".split("_"),monthsShort:"\u0d1c\u0d28\u0d41._\u0d2b\u0d46\u0d2c\u0d4d\u0d30\u0d41._\u0d2e\u0d3e\u0d7c._\u0d0f\u0d2a\u0d4d\u0d30\u0d3f._\u0d2e\u0d47\u0d2f\u0d4d_\u0d1c\u0d42\u0d7a_\u0d1c\u0d42\u0d32\u0d48._\u0d13\u0d17._\u0d38\u0d46\u0d2a\u0d4d\u0d31\u0d4d\u0d31._\u0d12\u0d15\u0d4d\u0d1f\u0d4b._\u0d28\u0d35\u0d02._\u0d21\u0d3f\u0d38\u0d02.".split("_"),weekdaysMin:"\u0d1e\u0d3e_\u0d24\u0d3f_\u0d1a\u0d4a_\u0d2c\u0d41_\u0d35\u0d4d\u0d2f\u0d3e_\u0d35\u0d46_\u0d36".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm -\u0d28\u0d41",LTS:"A h:mm:ss -\u0d28\u0d41",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm -\u0d28\u0d41",LLLL:"dddd, D MMMM YYYY, A h:mm -\u0d28\u0d41"},relativeTime:{future:"%s \u0d15\u0d34\u0d3f\u0d1e\u0d4d\u0d1e\u0d4d",past:"%s \u0d2e\u0d41\u0d7b\u0d2a\u0d4d",s:"\u0d05\u0d7d\u0d2a \u0d28\u0d3f\u0d2e\u0d3f\u0d37\u0d19\u0d4d\u0d19\u0d7e",m:"\u0d12\u0d30\u0d41 \u0d2e\u0d3f\u0d28\u0d3f\u0d31\u0d4d\u0d31\u0d4d",mm:"%d \u0d2e\u0d3f\u0d28\u0d3f\u0d31\u0d4d\u0d31\u0d4d",h:"\u0d12\u0d30\u0d41 \u0d2e\u0d23\u0d3f\u0d15\u0d4d\u0d15\u0d42\u0d7c",hh:"%d \u0d2e\u0d23\u0d3f\u0d15\u0d4d\u0d15\u0d42\u0d7c",d:"\u0d12\u0d30\u0d41 \u0d26\u0d3f\u0d35\u0d38\u0d02",dd:"%d \u0d26\u0d3f\u0d35\u0d38\u0d02",M:"\u0d12\u0d30\u0d41 \u0d2e\u0d3e\u0d38\u0d02",MM:"%d \u0d2e\u0d3e\u0d38\u0d02",y:"\u0d12\u0d30\u0d41 \u0d35\u0d7c\u0d37\u0d02",yy:"%d \u0d35\u0d7c\u0d37\u0d02"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/16758.3630f667.chunk.js b/ydb/core/viewer/monitoring/static/js/16758.3630f667.chunk.js new file mode 100644 index 000000000000..7022dea18b66 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16758.3630f667.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16758],{16758:(t,e,i)=>{i.d(e,{default:()=>a});var n=i(25833);const a=i.n(n)()},25833:t=>{function e(t){t.languages.nix={comment:{pattern:/\/\*[\s\S]*?\*\/|#.*/,greedy:!0},string:{pattern:/"(?:[^"\\]|\\[\s\S])*"|''(?:(?!'')[\s\S]|''(?:'|\\|\$\{))*''/,greedy:!0,inside:{interpolation:{pattern:/(^|(?:^|(?!'').)[^\\])\$\{(?:[^{}]|\{[^}]*\})*\}/,lookbehind:!0,inside:null}}},url:[/\b(?:[a-z]{3,7}:\/\/)[\w\-+%~\/.:#=?&]+/,{pattern:/([^\/])(?:[\w\-+%~.:#=?&]*(?!\/\/)[\w\-+%~\/.:#=?&])?(?!\/\/)\/[\w\-+%~\/.:#=?&]*/,lookbehind:!0}],antiquotation:{pattern:/\$(?=\{)/,alias:"important"},number:/\b\d+\b/,keyword:/\b(?:assert|builtins|else|if|in|inherit|let|null|or|then|with)\b/,function:/\b(?:abort|add|all|any|attrNames|attrValues|baseNameOf|compareVersions|concatLists|currentSystem|deepSeq|derivation|dirOf|div|elem(?:At)?|fetch(?:Tarball|url)|filter(?:Source)?|fromJSON|genList|getAttr|getEnv|hasAttr|hashString|head|import|intersectAttrs|is(?:Attrs|Bool|Function|Int|List|Null|String)|length|lessThan|listToAttrs|map|mul|parseDrvName|pathExists|read(?:Dir|File)|removeAttrs|replaceStrings|seq|sort|stringLength|sub(?:string)?|tail|throw|to(?:File|JSON|Path|String|XML)|trace|typeOf)\b|\bfoldl'\B/,boolean:/\b(?:false|true)\b/,operator:/[=!<>]=?|\+\+?|\|\||&&|\/\/|->?|[?@]/,punctuation:/[{}()[\].,:;]/},t.languages.nix.string.inside.interpolation.inside=t.languages.nix}t.exports=e,e.displayName="nix",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/16795.c5c2f8ec.chunk.js b/ydb/core/viewer/monitoring/static/js/16795.c5c2f8ec.chunk.js new file mode 100644 index 000000000000..b0620115be90 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/16795.c5c2f8ec.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[16795],{16795:(e,t,o)=>{o.d(t,{default:()=>i});var r=o(30784);const i=o.n(r)()},30784:e=>{function t(e){e.languages.mel={comment:/\/\/.*/,code:{pattern:/`(?:\\.|[^\\`\r\n])*`/,greedy:!0,alias:"italic",inside:{delimiter:{pattern:/^`|`$/,alias:"punctuation"}}},string:{pattern:/"(?:\\.|[^\\"\r\n])*"/,greedy:!0},variable:/\$\w+/,number:/\b0x[\da-fA-F]+\b|\b\d+(?:\.\d*)?|\B\.\d+/,flag:{pattern:/-[^\d\W]\w*/,alias:"operator"},keyword:/\b(?:break|case|continue|default|do|else|float|for|global|if|in|int|matrix|proc|return|string|switch|vector|while)\b/,function:/\b\w+(?=\()|\b(?:CBG|HfAddAttractorToAS|HfAssignAS|HfBuildEqualMap|HfBuildFurFiles|HfBuildFurImages|HfCancelAFR|HfConnectASToHF|HfCreateAttractor|HfDeleteAS|HfEditAS|HfPerformCreateAS|HfRemoveAttractorFromAS|HfSelectAttached|HfSelectAttractors|HfUnAssignAS|Mayatomr|about|abs|addAttr|addAttributeEditorNodeHelp|addDynamic|addNewShelfTab|addPP|addPanelCategory|addPrefixToName|advanceToNextDrivenKey|affectedNet|affects|aimConstraint|air|alias|aliasAttr|align|alignCtx|alignCurve|alignSurface|allViewFit|ambientLight|angle|angleBetween|animCone|animCurveEditor|animDisplay|animView|annotate|appendStringArray|applicationName|applyAttrPreset|applyTake|arcLenDimContext|arcLengthDimension|arclen|arrayMapper|art3dPaintCtx|artAttrCtx|artAttrPaintVertexCtx|artAttrSkinPaintCtx|artAttrTool|artBuildPaintMenu|artFluidAttrCtx|artPuttyCtx|artSelectCtx|artSetPaintCtx|artUserPaintCtx|assignCommand|assignInputDevice|assignViewportFactories|attachCurve|attachDeviceAttr|attachSurface|attrColorSliderGrp|attrCompatibility|attrControlGrp|attrEnumOptionMenu|attrEnumOptionMenuGrp|attrFieldGrp|attrFieldSliderGrp|attrNavigationControlGrp|attrPresetEditWin|attributeExists|attributeInfo|attributeMenu|attributeQuery|autoKeyframe|autoPlace|bakeClip|bakeFluidShading|bakePartialHistory|bakeResults|bakeSimulation|basename|basenameEx|batchRender|bessel|bevel|bevelPlus|binMembership|bindSkin|blend2|blendShape|blendShapeEditor|blendShapePanel|blendTwoAttr|blindDataType|boneLattice|boundary|boxDollyCtx|boxZoomCtx|bufferCurve|buildBookmarkMenu|buildKeyframeMenu|button|buttonManip|cacheFile|cacheFileCombine|cacheFileMerge|cacheFileTrack|camera|cameraView|canCreateManip|canvas|capitalizeString|catch|catchQuiet|ceil|changeSubdivComponentDisplayLevel|changeSubdivRegion|channelBox|character|characterMap|characterOutlineEditor|characterize|chdir|checkBox|checkBoxGrp|checkDefaultRenderGlobals|choice|circle|circularFillet|clamp|clear|clearCache|clip|clipEditor|clipEditorCurrentTimeCtx|clipSchedule|clipSchedulerOutliner|clipTrimBefore|closeCurve|closeSurface|cluster|cmdFileOutput|cmdScrollFieldExecuter|cmdScrollFieldReporter|cmdShell|coarsenSubdivSelectionList|collision|color|colorAtPoint|colorEditor|colorIndex|colorIndexSliderGrp|colorSliderButtonGrp|colorSliderGrp|columnLayout|commandEcho|commandLine|commandPort|compactHairSystem|componentEditor|compositingInterop|computePolysetVolume|condition|cone|confirmDialog|connectAttr|connectControl|connectDynamic|connectJoint|connectionInfo|constrain|constrainValue|constructionHistory|container|containsMultibyte|contextInfo|control|convertFromOldLayers|convertIffToPsd|convertLightmap|convertSolidTx|convertTessellation|convertUnit|copyArray|copyFlexor|copyKey|copySkinWeights|cos|cpButton|cpCache|cpClothSet|cpCollision|cpConstraint|cpConvClothToMesh|cpForces|cpGetSolverAttr|cpPanel|cpProperty|cpRigidCollisionFilter|cpSeam|cpSetEdit|cpSetSolverAttr|cpSolver|cpSolverTypes|cpTool|cpUpdateClothUVs|createDisplayLayer|createDrawCtx|createEditor|createLayeredPsdFile|createMotionField|createNewShelf|createNode|createRenderLayer|createSubdivRegion|cross|crossProduct|ctxAbort|ctxCompletion|ctxEditMode|ctxTraverse|currentCtx|currentTime|currentTimeCtx|currentUnit|curve|curveAddPtCtx|curveCVCtx|curveEPCtx|curveEditorCtx|curveIntersect|curveMoveEPCtx|curveOnSurface|curveSketchCtx|cutKey|cycleCheck|cylinder|dagPose|date|defaultLightListCheckBox|defaultNavigation|defineDataServer|defineVirtualDevice|deformer|deg_to_rad|delete|deleteAttr|deleteShadingGroupsAndMaterials|deleteShelfTab|deleteUI|deleteUnusedBrushes|delrandstr|detachCurve|detachDeviceAttr|detachSurface|deviceEditor|devicePanel|dgInfo|dgdirty|dgeval|dgtimer|dimWhen|directKeyCtx|directionalLight|dirmap|dirname|disable|disconnectAttr|disconnectJoint|diskCache|displacementToPoly|displayAffected|displayColor|displayCull|displayLevelOfDetail|displayPref|displayRGBColor|displaySmoothness|displayStats|displayString|displaySurface|distanceDimContext|distanceDimension|doBlur|dolly|dollyCtx|dopeSheetEditor|dot|dotProduct|doubleProfileBirailSurface|drag|dragAttrContext|draggerContext|dropoffLocator|duplicate|duplicateCurve|duplicateSurface|dynCache|dynControl|dynExport|dynExpression|dynGlobals|dynPaintEditor|dynParticleCtx|dynPref|dynRelEdPanel|dynRelEditor|dynamicLoad|editAttrLimits|editDisplayLayerGlobals|editDisplayLayerMembers|editRenderLayerAdjustment|editRenderLayerGlobals|editRenderLayerMembers|editor|editorTemplate|effector|emit|emitter|enableDevice|encodeString|endString|endsWith|env|equivalent|equivalentTol|erf|error|eval|evalDeferred|evalEcho|event|exactWorldBoundingBox|exclusiveLightCheckBox|exec|executeForEachObject|exists|exp|expression|expressionEditorListen|extendCurve|extendSurface|extrude|fcheck|fclose|feof|fflush|fgetline|fgetword|file|fileBrowserDialog|fileDialog|fileExtension|fileInfo|filetest|filletCurve|filter|filterCurve|filterExpand|filterStudioImport|findAllIntersections|findAnimCurves|findKeyframe|findMenuItem|findRelatedSkinCluster|finder|firstParentOf|fitBspline|flexor|floatEq|floatField|floatFieldGrp|floatScrollBar|floatSlider|floatSlider2|floatSliderButtonGrp|floatSliderGrp|floor|flow|fluidCacheInfo|fluidEmitter|fluidVoxelInfo|flushUndo|fmod|fontDialog|fopen|formLayout|format|fprint|frameLayout|fread|freeFormFillet|frewind|fromNativePath|fwrite|gamma|gauss|geometryConstraint|getApplicationVersionAsFloat|getAttr|getClassification|getDefaultBrush|getFileList|getFluidAttr|getInputDeviceRange|getMayaPanelTypes|getModifiers|getPanel|getParticleAttr|getPluginResource|getenv|getpid|glRender|glRenderEditor|globalStitch|gmatch|goal|gotoBindPose|grabColor|gradientControl|gradientControlNoAttr|graphDollyCtx|graphSelectContext|graphTrackCtx|gravity|grid|gridLayout|group|groupObjectsByName|hardenPointCurve|hardware|hardwareRenderPanel|headsUpDisplay|headsUpMessage|help|helpLine|hermite|hide|hilite|hitTest|hotBox|hotkey|hotkeyCheck|hsv_to_rgb|hudButton|hudSlider|hudSliderButton|hwReflectionMap|hwRender|hwRenderLoad|hyperGraph|hyperPanel|hyperShade|hypot|iconTextButton|iconTextCheckBox|iconTextRadioButton|iconTextRadioCollection|iconTextScrollList|iconTextStaticLabel|ikHandle|ikHandleCtx|ikHandleDisplayScale|ikSolver|ikSplineHandleCtx|ikSystem|ikSystemInfo|ikfkDisplayMethod|illustratorCurves|image|imfPlugins|inheritTransform|insertJoint|insertJointCtx|insertKeyCtx|insertKnotCurve|insertKnotSurface|instance|instanceable|instancer|intField|intFieldGrp|intScrollBar|intSlider|intSliderGrp|interToUI|internalVar|intersect|iprEngine|isAnimCurve|isConnected|isDirty|isParentOf|isSameObject|isTrue|isValidObjectName|isValidString|isValidUiName|isolateSelect|itemFilter|itemFilterAttr|itemFilterRender|itemFilterType|joint|jointCluster|jointCtx|jointDisplayScale|jointLattice|keyTangent|keyframe|keyframeOutliner|keyframeRegionCurrentTimeCtx|keyframeRegionDirectKeyCtx|keyframeRegionDollyCtx|keyframeRegionInsertKeyCtx|keyframeRegionMoveKeyCtx|keyframeRegionScaleKeyCtx|keyframeRegionSelectKeyCtx|keyframeRegionSetKeyCtx|keyframeRegionTrackCtx|keyframeStats|lassoContext|lattice|latticeDeformKeyCtx|launch|launchImageEditor|layerButton|layeredShaderPort|layeredTexturePort|layout|layoutDialog|lightList|lightListEditor|lightListPanel|lightlink|lineIntersection|linearPrecision|linstep|listAnimatable|listAttr|listCameras|listConnections|listDeviceAttachments|listHistory|listInputDeviceAxes|listInputDeviceButtons|listInputDevices|listMenuAnnotation|listNodeTypes|listPanelCategories|listRelatives|listSets|listTransforms|listUnselected|listerEditor|loadFluid|loadNewShelf|loadPlugin|loadPluginLanguageResources|loadPrefObjects|localizedPanelLabel|lockNode|loft|log|longNameOf|lookThru|ls|lsThroughFilter|lsType|lsUI|mag|makeIdentity|makeLive|makePaintable|makeRoll|makeSingleSurface|makeTubeOn|makebot|manipMoveContext|manipMoveLimitsCtx|manipOptions|manipRotateContext|manipRotateLimitsCtx|manipScaleContext|manipScaleLimitsCtx|marker|match|max|memory|menu|menuBarLayout|menuEditor|menuItem|menuItemToShelf|menuSet|menuSetPref|messageLine|min|minimizeApp|mirrorJoint|modelCurrentTimeCtx|modelEditor|modelPanel|mouse|movIn|movOut|move|moveIKtoFK|moveKeyCtx|moveVertexAlongDirection|multiProfileBirailSurface|mute|nParticle|nameCommand|nameField|namespace|namespaceInfo|newPanelItems|newton|nodeCast|nodeIconButton|nodeOutliner|nodePreset|nodeType|noise|nonLinear|normalConstraint|normalize|nurbsBoolean|nurbsCopyUVSet|nurbsCube|nurbsEditUV|nurbsPlane|nurbsSelect|nurbsSquare|nurbsToPoly|nurbsToPolygonsPref|nurbsToSubdiv|nurbsToSubdivPref|nurbsUVSet|nurbsViewDirectionVector|objExists|objectCenter|objectLayer|objectType|objectTypeUI|obsoleteProc|oceanNurbsPreviewPlane|offsetCurve|offsetCurveOnSurface|offsetSurface|openGLExtension|openMayaPref|optionMenu|optionMenuGrp|optionVar|orbit|orbitCtx|orientConstraint|outlinerEditor|outlinerPanel|overrideModifier|paintEffectsDisplay|pairBlend|palettePort|paneLayout|panel|panelConfiguration|panelHistory|paramDimContext|paramDimension|paramLocator|parent|parentConstraint|particle|particleExists|particleInstancer|particleRenderInfo|partition|pasteKey|pathAnimation|pause|pclose|percent|performanceOptions|pfxstrokes|pickWalk|picture|pixelMove|planarSrf|plane|play|playbackOptions|playblast|plugAttr|plugNode|pluginInfo|pluginResourceUtil|pointConstraint|pointCurveConstraint|pointLight|pointMatrixMult|pointOnCurve|pointOnSurface|pointPosition|poleVectorConstraint|polyAppend|polyAppendFacetCtx|polyAppendVertex|polyAutoProjection|polyAverageNormal|polyAverageVertex|polyBevel|polyBlendColor|polyBlindData|polyBoolOp|polyBridgeEdge|polyCacheMonitor|polyCheck|polyChipOff|polyClipboard|polyCloseBorder|polyCollapseEdge|polyCollapseFacet|polyColorBlindData|polyColorDel|polyColorPerVertex|polyColorSet|polyCompare|polyCone|polyCopyUV|polyCrease|polyCreaseCtx|polyCreateFacet|polyCreateFacetCtx|polyCube|polyCut|polyCutCtx|polyCylinder|polyCylindricalProjection|polyDelEdge|polyDelFacet|polyDelVertex|polyDuplicateAndConnect|polyDuplicateEdge|polyEditUV|polyEditUVShell|polyEvaluate|polyExtrudeEdge|polyExtrudeFacet|polyExtrudeVertex|polyFlipEdge|polyFlipUV|polyForceUV|polyGeoSampler|polyHelix|polyInfo|polyInstallAction|polyLayoutUV|polyListComponentConversion|polyMapCut|polyMapDel|polyMapSew|polyMapSewMove|polyMergeEdge|polyMergeEdgeCtx|polyMergeFacet|polyMergeFacetCtx|polyMergeUV|polyMergeVertex|polyMirrorFace|polyMoveEdge|polyMoveFacet|polyMoveFacetUV|polyMoveUV|polyMoveVertex|polyNormal|polyNormalPerVertex|polyNormalizeUV|polyOptUvs|polyOptions|polyOutput|polyPipe|polyPlanarProjection|polyPlane|polyPlatonicSolid|polyPoke|polyPrimitive|polyPrism|polyProjection|polyPyramid|polyQuad|polyQueryBlindData|polyReduce|polySelect|polySelectConstraint|polySelectConstraintMonitor|polySelectCtx|polySelectEditCtx|polySeparate|polySetToFaceNormal|polySewEdge|polyShortestPathCtx|polySmooth|polySoftEdge|polySphere|polySphericalProjection|polySplit|polySplitCtx|polySplitEdge|polySplitRing|polySplitVertex|polyStraightenUVBorder|polySubdivideEdge|polySubdivideFacet|polyToSubdiv|polyTorus|polyTransfer|polyTriangulate|polyUVSet|polyUnite|polyWedgeFace|popen|popupMenu|pose|pow|preloadRefEd|print|progressBar|progressWindow|projFileViewer|projectCurve|projectTangent|projectionContext|projectionManip|promptDialog|propModCtx|propMove|psdChannelOutliner|psdEditTextureFile|psdExport|psdTextureFile|putenv|pwd|python|querySubdiv|quit|rad_to_deg|radial|radioButton|radioButtonGrp|radioCollection|radioMenuItemCollection|rampColorPort|rand|randomizeFollicles|randstate|rangeControl|readTake|rebuildCurve|rebuildSurface|recordAttr|recordDevice|redo|reference|referenceEdit|referenceQuery|refineSubdivSelectionList|refresh|refreshAE|registerPluginResource|rehash|reloadImage|removeJoint|removeMultiInstance|removePanelCategory|rename|renameAttr|renameSelectionList|renameUI|render|renderGlobalsNode|renderInfo|renderLayerButton|renderLayerParent|renderLayerPostProcess|renderLayerUnparent|renderManip|renderPartition|renderQualityNode|renderSettings|renderThumbnailUpdate|renderWindowEditor|renderWindowSelectContext|renderer|reorder|reorderDeformers|requires|reroot|resampleFluid|resetAE|resetPfxToPolyCamera|resetTool|resolutionNode|retarget|reverseCurve|reverseSurface|revolve|rgb_to_hsv|rigidBody|rigidSolver|roll|rollCtx|rootOf|rot|rotate|rotationInterpolation|roundConstantRadius|rowColumnLayout|rowLayout|runTimeCommand|runup|sampleImage|saveAllShelves|saveAttrPreset|saveFluid|saveImage|saveInitialState|saveMenu|savePrefObjects|savePrefs|saveShelf|saveToolSettings|scale|scaleBrushBrightness|scaleComponents|scaleConstraint|scaleKey|scaleKeyCtx|sceneEditor|sceneUIReplacement|scmh|scriptCtx|scriptEditorInfo|scriptJob|scriptNode|scriptTable|scriptToShelf|scriptedPanel|scriptedPanelType|scrollField|scrollLayout|sculpt|searchPathArray|seed|selLoadSettings|select|selectContext|selectCurveCV|selectKey|selectKeyCtx|selectKeyframeRegionCtx|selectMode|selectPref|selectPriority|selectType|selectedNodes|selectionConnection|separator|setAttr|setAttrEnumResource|setAttrMapping|setAttrNiceNameResource|setConstraintRestPosition|setDefaultShadingGroup|setDrivenKeyframe|setDynamic|setEditCtx|setEditor|setFluidAttr|setFocus|setInfinity|setInputDeviceMapping|setKeyCtx|setKeyPath|setKeyframe|setKeyframeBlendshapeTargetWts|setMenuMode|setNodeNiceNameResource|setNodeTypeFlag|setParent|setParticleAttr|setPfxToPolyCamera|setPluginResource|setProject|setStampDensity|setStartupMessage|setState|setToolTo|setUITemplate|setXformManip|sets|shadingConnection|shadingGeometryRelCtx|shadingLightRelCtx|shadingNetworkCompare|shadingNode|shapeCompare|shelfButton|shelfLayout|shelfTabLayout|shellField|shortNameOf|showHelp|showHidden|showManipCtx|showSelectionInTitle|showShadingGroupAttrEditor|showWindow|sign|simplify|sin|singleProfileBirailSurface|size|sizeBytes|skinCluster|skinPercent|smoothCurve|smoothTangentSurface|smoothstep|snap2to2|snapKey|snapMode|snapTogetherCtx|snapshot|soft|softMod|softModCtx|sort|sound|soundControl|source|spaceLocator|sphere|sphrand|spotLight|spotLightPreviewPort|spreadSheetEditor|spring|sqrt|squareSurface|srtContext|stackTrace|startString|startsWith|stitchAndExplodeShell|stitchSurface|stitchSurfacePoints|strcmp|stringArrayCatenate|stringArrayContains|stringArrayCount|stringArrayInsertAtIndex|stringArrayIntersector|stringArrayRemove|stringArrayRemoveAtIndex|stringArrayRemoveDuplicates|stringArrayRemoveExact|stringArrayToString|stringToStringArray|strip|stripPrefixFromName|stroke|subdAutoProjection|subdCleanTopology|subdCollapse|subdDuplicateAndConnect|subdEditUV|subdListComponentConversion|subdMapCut|subdMapSewMove|subdMatchTopology|subdMirror|subdToBlind|subdToPoly|subdTransferUVsToCache|subdiv|subdivCrease|subdivDisplaySmoothness|substitute|substituteAllString|substituteGeometry|substring|surface|surfaceSampler|surfaceShaderList|swatchDisplayPort|switchTable|symbolButton|symbolCheckBox|sysFile|system|tabLayout|tan|tangentConstraint|texLatticeDeformContext|texManipContext|texMoveContext|texMoveUVShellContext|texRotateContext|texScaleContext|texSelectContext|texSelectShortestPathCtx|texSmudgeUVContext|texWinToolCtx|text|textCurves|textField|textFieldButtonGrp|textFieldGrp|textManip|textScrollList|textToShelf|textureDisplacePlane|textureHairColor|texturePlacementContext|textureWindow|threadCount|threePointArcCtx|timeControl|timePort|timerX|toNativePath|toggle|toggleAxis|toggleWindowVisibility|tokenize|tokenizeList|tolerance|tolower|toolButton|toolCollection|toolDropped|toolHasOptions|toolPropertyWindow|torus|toupper|trace|track|trackCtx|transferAttributes|transformCompare|transformLimits|translator|trim|trunc|truncateFluidCache|truncateHairCache|tumble|tumbleCtx|turbulence|twoPointArcCtx|uiRes|uiTemplate|unassignInputDevice|undo|undoInfo|ungroup|uniform|unit|unloadPlugin|untangleUV|untitledFileName|untrim|upAxis|updateAE|userCtx|uvLink|uvSnapshot|validateShelfName|vectorize|view2dToolCtx|viewCamera|viewClipPlane|viewFit|viewHeadOn|viewLookAt|viewManip|viewPlace|viewSet|visor|volumeAxis|vortex|waitCursor|warning|webBrowser|webBrowserPrefs|whatIs|window|windowPref|wire|wireContext|workspace|wrinkle|wrinkleContext|writeTake|xbmLangPathList|xform)\b/,operator:[/\+[+=]?|-[-=]?|&&|\|\||[<>]=|[*\/!=]=?|[%^]/,{pattern:/(^|[^<])<(?!<)/,lookbehind:!0},{pattern:/(^|[^>])>(?!>)/,lookbehind:!0}],punctuation:/<<|>>|[.,:;?\[\](){}]/},e.languages.mel.code.inside.rest=e.languages.mel}e.exports=t,t.displayName="mel",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1696.6120f4a8.chunk.js b/ydb/core/viewer/monitoring/static/js/1696.6120f4a8.chunk.js deleted file mode 100644 index 925c5afde750..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1696.6120f4a8.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1696],{41696:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e),a={s:"ein paar Sekunden",m:["eine Minute","einer Minute"],mm:"%d Minuten",h:["eine Stunde","einer Stunde"],hh:"%d Stunden",d:["ein Tag","einem Tag"],dd:["%d Tage","%d Tagen"],M:["ein Monat","einem Monat"],MM:["%d Monate","%d Monaten"],y:["ein Jahr","einem Jahr"],yy:["%d Jahre","%d Jahren"]};function i(e,n,t){var i=a[t];return Array.isArray(i)&&(i=i[n?0:1]),i.replace("%d",e)}var _={name:"de-ch",weekdays:"Sonntag_Montag_Dienstag_Mittwoch_Donnerstag_Freitag_Samstag".split("_"),weekdaysShort:"So_Mo_Di_Mi_Do_Fr_Sa".split("_"),weekdaysMin:"So_Mo_Di_Mi_Do_Fr_Sa".split("_"),months:"Januar_Februar_M\xe4rz_April_Mai_Juni_Juli_August_September_Oktober_November_Dezember".split("_"),monthsShort:"Jan._Feb._M\xe4rz_Apr._Mai_Juni_Juli_Aug._Sep._Okt._Nov._Dez.".split("_"),ordinal:function(e){return e+"."},weekStart:1,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY HH:mm",LLLL:"dddd, D. MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"vor %s",s:i,m:i,mm:i,h:i,hh:i,d:i,dd:i,M:i,MM:i,y:i,yy:i}};return t.default.locale(_,null,!0),_}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/17240.74653f76.chunk.js b/ydb/core/viewer/monitoring/static/js/17240.74653f76.chunk.js new file mode 100644 index 000000000000..7421b128c13f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/17240.74653f76.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[17240],{17240:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),s={name:"ms-my",weekdays:"Ahad_Isnin_Selasa_Rabu_Khamis_Jumaat_Sabtu".split("_"),months:"Januari_Februari_Mac_April_Mei_Jun_Julai_Ogos_September_Oktober_November_Disember".split("_"),weekStart:1,weekdaysShort:"Ahd_Isn_Sel_Rab_Kha_Jum_Sab".split("_"),monthsShort:"Jan_Feb_Mac_Apr_Mei_Jun_Jul_Ogs_Sep_Okt_Nov_Dis".split("_"),weekdaysMin:"Ah_Is_Sl_Rb_Km_Jm_Sb".split("_"),ordinal:function(e){return e},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [pukul] HH.mm",LLLL:"dddd, D MMMM YYYY [pukul] HH.mm"},relativeTime:{future:"dalam %s",past:"%s yang lepas",s:"beberapa saat",m:"seminit",mm:"%d minit",h:"sejam",hh:"%d jam",d:"sehari",dd:"%d hari",M:"sebulan",MM:"%d bulan",y:"setahun",yy:"%d tahun"}};return _.default.locale(s,null,!0),s}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/173.7f4af5fa.chunk.js b/ydb/core/viewer/monitoring/static/js/173.7f4af5fa.chunk.js new file mode 100644 index 000000000000..cf72aa064519 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/173.7f4af5fa.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[173],{173:(e,t,r)=>{r.d(t,{default:()=>a});var n=r(43954);const a=r.n(n)()},43954:(e,t,r)=>{var n=r(93292);function a(e){e.register(n),e.languages.arduino=e.languages.extend("cpp",{keyword:/\b(?:String|array|bool|boolean|break|byte|case|catch|continue|default|do|double|else|finally|for|function|goto|if|in|instanceof|int|integer|long|loop|new|null|return|setup|string|switch|throw|try|void|while|word)\b/,constant:/\b(?:ANALOG_MESSAGE|DEFAULT|DIGITAL_MESSAGE|EXTERNAL|FIRMATA_STRING|HIGH|INPUT|INPUT_PULLUP|INTERNAL|INTERNAL1V1|INTERNAL2V56|LED_BUILTIN|LOW|OUTPUT|REPORT_ANALOG|REPORT_DIGITAL|SET_PIN_MODE|SYSEX_START|SYSTEM_RESET)\b/,builtin:/\b(?:Audio|BSSID|Bridge|Client|Console|EEPROM|Esplora|EsploraTFT|Ethernet|EthernetClient|EthernetServer|EthernetUDP|File|FileIO|FileSystem|Firmata|GPRS|GSM|GSMBand|GSMClient|GSMModem|GSMPIN|GSMScanner|GSMServer|GSMVoiceCall|GSM_SMS|HttpClient|IPAddress|IRread|Keyboard|KeyboardController|LiquidCrystal|LiquidCrystal_I2C|Mailbox|Mouse|MouseController|PImage|Process|RSSI|RobotControl|RobotMotor|SD|SPI|SSID|Scheduler|Serial|Server|Servo|SoftwareSerial|Stepper|Stream|TFT|Task|USBHost|WiFi|WiFiClient|WiFiServer|WiFiUDP|Wire|YunClient|YunServer|abs|addParameter|analogRead|analogReadResolution|analogReference|analogWrite|analogWriteResolution|answerCall|attach|attachGPRS|attachInterrupt|attached|autoscroll|available|background|beep|begin|beginPacket|beginSD|beginSMS|beginSpeaker|beginTFT|beginTransmission|beginWrite|bit|bitClear|bitRead|bitSet|bitWrite|blink|blinkVersion|buffer|changePIN|checkPIN|checkPUK|checkReg|circle|cityNameRead|cityNameWrite|clear|clearScreen|click|close|compassRead|config|connect|connected|constrain|cos|countryNameRead|countryNameWrite|createChar|cursor|debugPrint|delay|delayMicroseconds|detach|detachInterrupt|digitalRead|digitalWrite|disconnect|display|displayLogos|drawBMP|drawCompass|encryptionType|end|endPacket|endSMS|endTransmission|endWrite|exists|exitValue|fill|find|findUntil|flush|gatewayIP|get|getAsynchronously|getBand|getButton|getCurrentCarrier|getIMEI|getKey|getModifiers|getOemKey|getPINUsed|getResult|getSignalStrength|getSocket|getVoiceCallStatus|getXChange|getYChange|hangCall|height|highByte|home|image|interrupts|isActionDone|isDirectory|isListening|isPIN|isPressed|isValid|keyPressed|keyReleased|keyboardRead|knobRead|leftToRight|line|lineFollowConfig|listen|listenOnLocalhost|loadImage|localIP|lowByte|macAddress|maintain|map|max|messageAvailable|micros|millis|min|mkdir|motorsStop|motorsWrite|mouseDragged|mouseMoved|mousePressed|mouseReleased|move|noAutoscroll|noBlink|noBuffer|noCursor|noDisplay|noFill|noInterrupts|noListenOnLocalhost|noStroke|noTone|onReceive|onRequest|open|openNextFile|overflow|parseCommand|parseFloat|parseInt|parsePacket|pauseMode|peek|pinMode|playFile|playMelody|point|pointTo|position|pow|prepare|press|print|printFirmwareVersion|printVersion|println|process|processInput|pulseIn|put|random|randomSeed|read|readAccelerometer|readBlue|readButton|readBytes|readBytesUntil|readGreen|readJoystickButton|readJoystickSwitch|readJoystickX|readJoystickY|readLightSensor|readMessage|readMicrophone|readNetworks|readRed|readSlider|readString|readStringUntil|readTemperature|ready|rect|release|releaseAll|remoteIP|remoteNumber|remotePort|remove|requestFrom|retrieveCallingNumber|rewindDirectory|rightToLeft|rmdir|robotNameRead|robotNameWrite|run|runAsynchronously|runShellCommand|runShellCommandAsynchronously|running|scanNetworks|scrollDisplayLeft|scrollDisplayRight|seek|sendAnalog|sendDigitalPortPair|sendDigitalPorts|sendString|sendSysex|serialEvent|setBand|setBitOrder|setClockDivider|setCursor|setDNS|setDataMode|setFirmwareVersion|setMode|setPINUsed|setSpeed|setTextSize|setTimeout|shiftIn|shiftOut|shutdown|sin|size|sqrt|startLoop|step|stop|stroke|subnetMask|switchPIN|tan|tempoWrite|text|tone|transfer|tuneWrite|turn|updateIR|userNameRead|userNameWrite|voiceCall|waitContinue|width|write|writeBlue|writeGreen|writeJSON|writeMessage|writeMicroseconds|writeRGB|writeRed|yield)\b/}),e.languages.ino=e.languages.arduino}e.exports=a,a.displayName="arduino",a.aliases=["ino"]},89343:e=>{function t(e){e.languages.c=e.languages.extend("clike",{comment:{pattern:/\/\/(?:[^\r\n\\]|\\(?:\r\n?|\n|(?![\r\n])))*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"class-name":{pattern:/(\b(?:enum|struct)\s+(?:__attribute__\s*\(\([\s\S]*?\)\)\s*)?)\w+|\b[a-z]\w*_t\b/,lookbehind:!0},keyword:/\b(?:_Alignas|_Alignof|_Atomic|_Bool|_Complex|_Generic|_Imaginary|_Noreturn|_Static_assert|_Thread_local|__attribute__|asm|auto|break|case|char|const|continue|default|do|double|else|enum|extern|float|for|goto|if|inline|int|long|register|return|short|signed|sizeof|static|struct|switch|typedef|typeof|union|unsigned|void|volatile|while)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ful]{0,4}/i,operator:/>>=?|<<=?|->|([-+&|:])\1|[?:~]|[-+*/%&|^!=<>]=?/}),e.languages.insertBefore("c","string",{char:{pattern:/'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n]){0,32}'/,greedy:!0}}),e.languages.insertBefore("c","string",{macro:{pattern:/(^[\t ]*)#\s*[a-z](?:[^\r\n\\/]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{string:[{pattern:/^(#\s*include\s*)<[^>]+>/,lookbehind:!0},e.languages.c.string],char:e.languages.c.char,comment:e.languages.c.comment,"macro-name":[{pattern:/(^#\s*define\s+)\w+\b(?!\()/i,lookbehind:!0},{pattern:/(^#\s*define\s+)\w+\b(?=\()/i,lookbehind:!0,alias:"function"}],directive:{pattern:/^(#\s*)[a-z]+/,lookbehind:!0,alias:"keyword"},"directive-hash":/^#/,punctuation:/##|\\(?=[\r\n])/,expression:{pattern:/\S[\s\S]*/,inside:e.languages.c}}}}),e.languages.insertBefore("c","function",{constant:/\b(?:EOF|NULL|SEEK_CUR|SEEK_END|SEEK_SET|__DATE__|__FILE__|__LINE__|__TIMESTAMP__|__TIME__|__func__|stderr|stdin|stdout)\b/}),delete e.languages.c.boolean}e.exports=t,t.displayName="c",t.aliases=[]},93292:(e,t,r)=>{var n=r(89343);function a(e){e.register(n),function(e){var t=/\b(?:alignas|alignof|asm|auto|bool|break|case|catch|char|char16_t|char32_t|char8_t|class|co_await|co_return|co_yield|compl|concept|const|const_cast|consteval|constexpr|constinit|continue|decltype|default|delete|do|double|dynamic_cast|else|enum|explicit|export|extern|final|float|for|friend|goto|if|import|inline|int|int16_t|int32_t|int64_t|int8_t|long|module|mutable|namespace|new|noexcept|nullptr|operator|override|private|protected|public|register|reinterpret_cast|requires|return|short|signed|sizeof|static|static_assert|static_cast|struct|switch|template|this|thread_local|throw|try|typedef|typeid|typename|uint16_t|uint32_t|uint64_t|uint8_t|union|unsigned|using|virtual|void|volatile|wchar_t|while)\b/,r=/\b(?!)\w+(?:\s*\.\s*\w+)*\b/.source.replace(//g,(function(){return t.source}));e.languages.cpp=e.languages.extend("c",{"class-name":[{pattern:RegExp(/(\b(?:class|concept|enum|struct|typename)\s+)(?!)\w+/.source.replace(//g,(function(){return t.source}))),lookbehind:!0},/\b[A-Z]\w*(?=\s*::\s*\w+\s*\()/,/\b[A-Z_]\w*(?=\s*::\s*~\w+\s*\()/i,/\b\w+(?=\s*<(?:[^<>]|<(?:[^<>]|<[^<>]*>)*>)*>\s*::\s*\w+\s*\()/],keyword:t,number:{pattern:/(?:\b0b[01']+|\b0x(?:[\da-f']+(?:\.[\da-f']*)?|\.[\da-f']+)(?:p[+-]?[\d']+)?|(?:\b[\d']+(?:\.[\d']*)?|\B\.[\d']+)(?:e[+-]?[\d']+)?)[ful]{0,4}/i,greedy:!0},operator:/>>=?|<<=?|->|--|\+\+|&&|\|\||[?:~]|<=>|[-+*/%&|^!=<>]=?|\b(?:and|and_eq|bitand|bitor|not|not_eq|or|or_eq|xor|xor_eq)\b/,boolean:/\b(?:false|true)\b/}),e.languages.insertBefore("cpp","string",{module:{pattern:RegExp(/(\b(?:import|module)\s+)/.source+"(?:"+/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"|<[^<>\r\n]*>/.source+"|"+/(?:\s*:\s*)?|:\s*/.source.replace(//g,(function(){return r}))+")"),lookbehind:!0,greedy:!0,inside:{string:/^[<"][\s\S]+/,operator:/:/,punctuation:/\./}},"raw-string":{pattern:/R"([^()\\ ]{0,16})\([\s\S]*?\)\1"/,alias:"string",greedy:!0}}),e.languages.insertBefore("cpp","keyword",{"generic-function":{pattern:/\b(?!operator\b)[a-z_]\w*\s*<(?:[^<>]|<[^<>]*>)*>(?=\s*\()/i,inside:{function:/^\w+/,generic:{pattern:/<[\s\S]+/,alias:"class-name",inside:e.languages.cpp}}}}),e.languages.insertBefore("cpp","operator",{"double-colon":{pattern:/::/,alias:"punctuation"}}),e.languages.insertBefore("cpp","class-name",{"base-clause":{pattern:/(\b(?:class|struct)\s+\w+\s*:\s*)[^;{}"'\s]+(?:\s+[^;{}"'\s]+)*(?=\s*[;{])/,lookbehind:!0,greedy:!0,inside:e.languages.extend("cpp",{})}}),e.languages.insertBefore("inside","double-colon",{"class-name":/\b[a-z_]\w*\b(?!\s*::)/i},e.languages.cpp["base-clause"])}(e)}e.exports=a,a.displayName="cpp",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1747.f01c9fd8.chunk.js b/ydb/core/viewer/monitoring/static/js/1747.f01c9fd8.chunk.js deleted file mode 100644 index 0f4745d33888..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1747.f01c9fd8.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1747],{81747:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"en-tt",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},ordinal:function(e){var a=["th","st","nd","rd"],_=e%100;return"["+e+(a[(_-20)%10]||a[_]||a[0])+"]"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/17500.d2b3273a.chunk.js b/ydb/core/viewer/monitoring/static/js/17500.d2b3273a.chunk.js new file mode 100644 index 000000000000..fb311f7f2852 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/17500.d2b3273a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[17500],{17500:(e,i,t)=>{t.d(i,{default:()=>n});var r=t(91993);const n=t.n(r)()},91993:e=>{function i(e){!function(e){var i=e.languages.powershell={comment:[{pattern:/(^|[^`])<#[\s\S]*?#>/,lookbehind:!0},{pattern:/(^|[^`])#.*/,lookbehind:!0}],string:[{pattern:/"(?:`[\s\S]|[^`"])*"/,greedy:!0,inside:null},{pattern:/'(?:[^']|'')*'/,greedy:!0}],namespace:/\[[a-z](?:\[(?:\[[^\]]*\]|[^\[\]])*\]|[^\[\]])*\]/i,boolean:/\$(?:false|true)\b/i,variable:/\$\w+\b/,function:[/\b(?:Add|Approve|Assert|Backup|Block|Checkpoint|Clear|Close|Compare|Complete|Compress|Confirm|Connect|Convert|ConvertFrom|ConvertTo|Copy|Debug|Deny|Disable|Disconnect|Dismount|Edit|Enable|Enter|Exit|Expand|Export|Find|ForEach|Format|Get|Grant|Group|Hide|Import|Initialize|Install|Invoke|Join|Limit|Lock|Measure|Merge|Move|New|Open|Optimize|Out|Ping|Pop|Protect|Publish|Push|Read|Receive|Redo|Register|Remove|Rename|Repair|Request|Reset|Resize|Resolve|Restart|Restore|Resume|Revoke|Save|Search|Select|Send|Set|Show|Skip|Sort|Split|Start|Step|Stop|Submit|Suspend|Switch|Sync|Tee|Test|Trace|Unblock|Undo|Uninstall|Unlock|Unprotect|Unpublish|Unregister|Update|Use|Wait|Watch|Where|Write)-[a-z]+\b/i,/\b(?:ac|cat|chdir|clc|cli|clp|clv|compare|copy|cp|cpi|cpp|cvpa|dbp|del|diff|dir|ebp|echo|epal|epcsv|epsn|erase|fc|fl|ft|fw|gal|gbp|gc|gci|gcs|gdr|gi|gl|gm|gp|gps|group|gsv|gu|gv|gwmi|iex|ii|ipal|ipcsv|ipsn|irm|iwmi|iwr|kill|lp|ls|measure|mi|mount|move|mp|mv|nal|ndr|ni|nv|ogv|popd|ps|pushd|pwd|rbp|rd|rdr|ren|ri|rm|rmdir|rni|rnp|rp|rv|rvpa|rwmi|sal|saps|sasv|sbp|sc|select|set|shcm|si|sl|sleep|sls|sort|sp|spps|spsv|start|sv|swmi|tee|trcm|type|write)\b/i],keyword:/\b(?:Begin|Break|Catch|Class|Continue|Data|Define|Do|DynamicParam|Else|ElseIf|End|Exit|Filter|Finally|For|ForEach|From|Function|If|InlineScript|Parallel|Param|Process|Return|Sequence|Switch|Throw|Trap|Try|Until|Using|Var|While|Workflow)\b/i,operator:{pattern:/(^|\W)(?:!|-(?:b?(?:and|x?or)|as|(?:Not)?(?:Contains|In|Like|Match)|eq|ge|gt|is(?:Not)?|Join|le|lt|ne|not|Replace|sh[lr])\b|-[-=]?|\+[+=]?|[*\/%]=?)/i,lookbehind:!0},punctuation:/[|{}[\];(),.]/};i.string[0].inside={function:{pattern:/(^|[^`])\$\((?:\$\([^\r\n()]*\)|(?!\$\()[^\r\n)])*\)/,lookbehind:!0,inside:i},boolean:i.boolean,variable:i.variable}}(e)}e.exports=i,i.displayName="powershell",i.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1756.b612458a.chunk.js b/ydb/core/viewer/monitoring/static/js/1756.b612458a.chunk.js deleted file mode 100644 index 1690d3366f67..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1756.b612458a.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1756],{71756:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"tg",weekdays:"\u044f\u043a\u0448\u0430\u043d\u0431\u0435_\u0434\u0443\u0448\u0430\u043d\u0431\u0435_\u0441\u0435\u0448\u0430\u043d\u0431\u0435_\u0447\u043e\u0440\u0448\u0430\u043d\u0431\u0435_\u043f\u0430\u043d\u04b7\u0448\u0430\u043d\u0431\u0435_\u04b7\u0443\u043c\u044a\u0430_\u0448\u0430\u043d\u0431\u0435".split("_"),months:"\u044f\u043d\u0432\u0430\u0440_\u0444\u0435\u0432\u0440\u0430\u043b_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0435\u043b_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043d\u0442\u044f\u0431\u0440_\u043e\u043a\u0442\u044f\u0431\u0440_\u043d\u043e\u044f\u0431\u0440_\u0434\u0435\u043a\u0430\u0431\u0440".split("_"),weekStart:1,weekdaysShort:"\u044f\u0448\u0431_\u0434\u0448\u0431_\u0441\u0448\u0431_\u0447\u0448\u0431_\u043f\u0448\u0431_\u04b7\u0443\u043c_\u0448\u043d\u0431".split("_"),monthsShort:"\u044f\u043d\u0432_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433_\u0441\u0435\u043d_\u043e\u043a\u0442_\u043d\u043e\u044f_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u044f\u0448_\u0434\u0448_\u0441\u0448_\u0447\u0448_\u043f\u0448_\u04b7\u043c_\u0448\u0431".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"\u0431\u0430\u044a\u0434\u0438 %s",past:"%s \u043f\u0435\u0448",s:"\u044f\u043a\u0447\u0430\u043d\u0434 \u0441\u043e\u043d\u0438\u044f",m:"\u044f\u043a \u0434\u0430\u049b\u0438\u049b\u0430",mm:"%d \u0434\u0430\u049b\u0438\u049b\u0430",h:"\u044f\u043a \u0441\u043e\u0430\u0442",hh:"%d \u0441\u043e\u0430\u0442",d:"\u044f\u043a \u0440\u04ef\u0437",dd:"%d \u0440\u04ef\u0437",M:"\u044f\u043a \u043c\u043e\u04b3",MM:"%d \u043c\u043e\u04b3",y:"\u044f\u043a \u0441\u043e\u043b",yy:"%d \u0441\u043e\u043b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/17830.763df207.chunk.js b/ydb/core/viewer/monitoring/static/js/17830.763df207.chunk.js new file mode 100644 index 000000000000..d6492e86351c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/17830.763df207.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[17830],{17830:(e,s,r)=>{r.d(s,{default:()=>a});var n=r(81347);const a=r.n(n)()},81347:(e,s,r)=>{var n=r(90323);function a(e){e.register(n),function(e){var s=/\/(?![/*])|\/\/.*[\r\n]|\/\*[^*]*(?:\*(?!\/)[^*]*)*\*\//.source,r=/@(?!")|"(?:[^\r\n\\"]|\\.)*"|@"(?:[^\\"]|""|\\[\s\S])*"(?!")/.source+"|"+/'(?:(?:[^\r\n'\\]|\\.|\\[Uux][\da-fA-F]{1,8})'|(?=[^\\](?!')))/.source;function n(e,n){for(var a=0;a/g,(function(){return"(?:"+e+")"}));return e.replace(//g,"[^\\s\\S]").replace(//g,"(?:"+r+")").replace(//g,"(?:"+s+")")}var a=n(/\((?:[^()'"@/]|||)*\)/.source,2),o=n(/\[(?:[^\[\]'"@/]|||)*\]/.source,2),t=n(/\{(?:[^{}'"@/]|||)*\}/.source,2),i=n(/<(?:[^<>'"@/]|||)*>/.source,2),c=/(?:\s(?:\s*[^\s>\/=]+(?:\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))|(?=[\s/>])))+)?/.source,u=/(?!\d)[^\s>\/=$<%]+/.source+c+/\s*\/?>/.source,l=/\B@?/.source+"(?:"+/<([a-zA-Z][\w:]*)/.source+c+/\s*>/.source+"(?:"+/[^<]/.source+"|"+/<\/?(?!\1\b)/.source+u+"|"+n(/<\1/.source+c+/\s*>/.source+"(?:"+/[^<]/.source+"|"+/<\/?(?!\1\b)/.source+u+"|)*"+/<\/\1\s*>/.source,2)+")*"+/<\/\1\s*>/.source+"|"+/{function s(e){!function(e){function s(e,s){return e.replace(/<<(\d+)>>/g,(function(e,r){return"(?:"+s[+r]+")"}))}function r(e,r,n){return RegExp(s(e,r),n||"")}function n(e,s){for(var r=0;r>/g,(function(){return"(?:"+e+")"}));return e.replace(/<>/g,"[^\\s\\S]")}var a="bool byte char decimal double dynamic float int long object sbyte short string uint ulong ushort var void",o="class enum interface record struct",t="add alias and ascending async await by descending from(?=\\s*(?:\\w|$)) get global group into init(?=\\s*;) join let nameof not notnull on or orderby partial remove select set unmanaged value when where with(?=\\s*{)",i="abstract as base break case catch checked const continue default delegate do else event explicit extern finally fixed for foreach goto if implicit in internal is lock namespace new null operator out override params private protected public readonly ref return sealed sizeof stackalloc static switch this throw try typeof unchecked unsafe using virtual volatile while yield";function c(e){return"\\b(?:"+e.trim().replace(/ /g,"|")+")\\b"}var u=c(o),l=RegExp(c(a+" "+o+" "+t+" "+i)),d=c(o+" "+t+" "+i),p=c(a+" "+o+" "+i),g=n(/<(?:[^<>;=+\-*/%&|^]|<>)*>/.source,2),h=n(/\((?:[^()]|<>)*\)/.source,2),b=/@?\b[A-Za-z_]\w*\b/.source,f=s(/<<0>>(?:\s*<<1>>)?/.source,[b,g]),m=s(/(?!<<0>>)<<1>>(?:\s*\.\s*<<1>>)*/.source,[d,f]),k=/\[\s*(?:,\s*)*\]/.source,y=s(/<<0>>(?:\s*(?:\?\s*)?<<1>>)*(?:\s*\?)?/.source,[m,k]),w=s(/[^,()<>[\];=+\-*/%&|^]|<<0>>|<<1>>|<<2>>/.source,[g,h,k]),v=s(/\(<<0>>+(?:,<<0>>+)+\)/.source,[w]),x=s(/(?:<<0>>|<<1>>)(?:\s*(?:\?\s*)?<<2>>)*(?:\s*\?)?/.source,[v,m,k]),_={keyword:l,punctuation:/[<>()?,.:[\]]/},S=/'(?:[^\r\n'\\]|\\.|\\[Uux][\da-fA-F]{1,8})'/.source,$=/"(?:\\.|[^\\"\r\n])*"/.source,B=/@"(?:""|\\[\s\S]|[^\\"])*"(?!")/.source;e.languages.csharp=e.languages.extend("clike",{string:[{pattern:r(/(^|[^$\\])<<0>>/.source,[B]),lookbehind:!0,greedy:!0},{pattern:r(/(^|[^@$\\])<<0>>/.source,[$]),lookbehind:!0,greedy:!0}],"class-name":[{pattern:r(/(\busing\s+static\s+)<<0>>(?=\s*;)/.source,[m]),lookbehind:!0,inside:_},{pattern:r(/(\busing\s+<<0>>\s*=\s*)<<1>>(?=\s*;)/.source,[b,x]),lookbehind:!0,inside:_},{pattern:r(/(\busing\s+)<<0>>(?=\s*=)/.source,[b]),lookbehind:!0},{pattern:r(/(\b<<0>>\s+)<<1>>/.source,[u,f]),lookbehind:!0,inside:_},{pattern:r(/(\bcatch\s*\(\s*)<<0>>/.source,[m]),lookbehind:!0,inside:_},{pattern:r(/(\bwhere\s+)<<0>>/.source,[b]),lookbehind:!0},{pattern:r(/(\b(?:is(?:\s+not)?|as)\s+)<<0>>/.source,[y]),lookbehind:!0,inside:_},{pattern:r(/\b<<0>>(?=\s+(?!<<1>>|with\s*\{)<<2>>(?:\s*[=,;:{)\]]|\s+(?:in|when)\b))/.source,[x,p,b]),inside:_}],keyword:l,number:/(?:\b0(?:x[\da-f_]*[\da-f]|b[01_]*[01])|(?:\B\.\d+(?:_+\d+)*|\b\d+(?:_+\d+)*(?:\.\d+(?:_+\d+)*)?)(?:e[-+]?\d+(?:_+\d+)*)?)(?:[dflmu]|lu|ul)?\b/i,operator:/>>=?|<<=?|[-=]>|([-+&|])\1|~|\?\?=?|[-+*/%&|^!=<>]=?/,punctuation:/\?\.?|::|[{}[\];(),.:]/}),e.languages.insertBefore("csharp","number",{range:{pattern:/\.\./,alias:"operator"}}),e.languages.insertBefore("csharp","punctuation",{"named-parameter":{pattern:r(/([(,]\s*)<<0>>(?=\s*:)/.source,[b]),lookbehind:!0,alias:"punctuation"}}),e.languages.insertBefore("csharp","class-name",{namespace:{pattern:r(/(\b(?:namespace|using)\s+)<<0>>(?:\s*\.\s*<<0>>)*(?=\s*[;{])/.source,[b]),lookbehind:!0,inside:{punctuation:/\./}},"type-expression":{pattern:r(/(\b(?:default|sizeof|typeof)\s*\(\s*(?!\s))(?:[^()\s]|\s(?!\s)|<<0>>)*(?=\s*\))/.source,[h]),lookbehind:!0,alias:"class-name",inside:_},"return-type":{pattern:r(/<<0>>(?=\s+(?:<<1>>\s*(?:=>|[({]|\.\s*this\s*\[)|this\s*\[))/.source,[x,m]),inside:_,alias:"class-name"},"constructor-invocation":{pattern:r(/(\bnew\s+)<<0>>(?=\s*[[({])/.source,[x]),lookbehind:!0,inside:_,alias:"class-name"},"generic-method":{pattern:r(/<<0>>\s*<<1>>(?=\s*\()/.source,[b,g]),inside:{function:r(/^<<0>>/.source,[b]),generic:{pattern:RegExp(g),alias:"class-name",inside:_}}},"type-list":{pattern:r(/\b((?:<<0>>\s+<<1>>|record\s+<<1>>\s*<<5>>|where\s+<<2>>)\s*:\s*)(?:<<3>>|<<4>>|<<1>>\s*<<5>>|<<6>>)(?:\s*,\s*(?:<<3>>|<<4>>|<<6>>))*(?=\s*(?:where|[{;]|=>|$))/.source,[u,f,b,x,l.source,h,/\bnew\s*\(\s*\)/.source]),lookbehind:!0,inside:{"record-arguments":{pattern:r(/(^(?!new\s*\()<<0>>\s*)<<1>>/.source,[f,h]),lookbehind:!0,greedy:!0,inside:e.languages.csharp},keyword:l,"class-name":{pattern:RegExp(x),greedy:!0,inside:_},punctuation:/[,()]/}},preprocessor:{pattern:/(^[\t ]*)#.*/m,lookbehind:!0,alias:"property",inside:{directive:{pattern:/(#)\b(?:define|elif|else|endif|endregion|error|if|line|nullable|pragma|region|undef|warning)\b/,lookbehind:!0,alias:"keyword"}}}});var E=$+"|"+S,R=s(/\/(?![*/])|\/\/[^\r\n]*[\r\n]|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>/.source,[E]),z=n(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[R]),2),j=/\b(?:assembly|event|field|method|module|param|property|return|type)\b/.source,A=s(/<<0>>(?:\s*\(<<1>>*\))?/.source,[m,z]);e.languages.insertBefore("csharp","class-name",{attribute:{pattern:r(/((?:^|[^\s\w>)?])\s*\[\s*)(?:<<0>>\s*:\s*)?<<1>>(?:\s*,\s*<<1>>)*(?=\s*\])/.source,[j,A]),lookbehind:!0,greedy:!0,inside:{target:{pattern:r(/^<<0>>(?=\s*:)/.source,[j]),alias:"keyword"},"attribute-arguments":{pattern:r(/\(<<0>>*\)/.source,[z]),inside:e.languages.csharp},"class-name":{pattern:RegExp(m),inside:{punctuation:/\./}},punctuation:/[:,]/}}});var T=/:[^}\r\n]+/.source,H=n(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[R]),2),C=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[H,T]),F=n(s(/[^"'/()]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>|\(<>*\)/.source,[E]),2),N=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[F,T]);function U(s,n){return{interpolation:{pattern:r(/((?:^|[^{])(?:\{\{)*)<<0>>/.source,[s]),lookbehind:!0,inside:{"format-string":{pattern:r(/(^\{(?:(?![}:])<<0>>)*)<<1>>(?=\}$)/.source,[n,T]),lookbehind:!0,inside:{punctuation:/^:/}},punctuation:/^\{|\}$/,expression:{pattern:/[\s\S]+/,alias:"language-csharp",inside:e.languages.csharp}}},string:/[\s\S]+/}}e.languages.insertBefore("csharp","string",{"interpolation-string":[{pattern:r(/(^|[^\\])(?:\$@|@\$)"(?:""|\\[\s\S]|\{\{|<<0>>|[^\\{"])*"/.source,[C]),lookbehind:!0,greedy:!0,inside:U(C,H)},{pattern:r(/(^|[^@\\])\$"(?:\\.|\{\{|<<0>>|[^\\"{])*"/.source,[N]),lookbehind:!0,greedy:!0,inside:U(N,F)}],char:{pattern:RegExp(S),greedy:!0}}),e.languages.dotnet=e.languages.cs=e.languages.csharp}(e)}e.exports=s,s.displayName="csharp",s.aliases=["dotnet","cs"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/17880.ed6168a4.chunk.js b/ydb/core/viewer/monitoring/static/js/17880.ed6168a4.chunk.js new file mode 100644 index 000000000000..53602c252043 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/17880.ed6168a4.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[17880],{17880:(e,s,a)=>{a.d(s,{default:()=>t});var n=a(29529);const t=a.n(n)()},29529:e=>{function s(e){e.languages.less=e.languages.extend("css",{comment:[/\/\*[\s\S]*?\*\//,{pattern:/(^|[^\\])\/\/.*/,lookbehind:!0}],atrule:{pattern:/@[\w-](?:\((?:[^(){}]|\([^(){}]*\))*\)|[^(){};\s]|\s+(?!\s))*?(?=\s*\{)/,inside:{punctuation:/[:()]/}},selector:{pattern:/(?:@\{[\w-]+\}|[^{};\s@])(?:@\{[\w-]+\}|\((?:[^(){}]|\([^(){}]*\))*\)|[^(){};@\s]|\s+(?!\s))*?(?=\s*\{)/,inside:{variable:/@+[\w-]+/}},property:/(?:@\{[\w-]+\}|[\w-])+(?:\+_?)?(?=\s*:)/,operator:/[+\-*\/]/}),e.languages.insertBefore("less","property",{variable:[{pattern:/@[\w-]+\s*:/,inside:{punctuation:/:/}},/@@?[\w-]+/],"mixin-usage":{pattern:/([{;]\s*)[.#](?!\d)[\w-].*?(?=[(;])/,lookbehind:!0,alias:"function"}})}e.exports=s,s.displayName="less",s.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/17981.5fd12b3d.chunk.js b/ydb/core/viewer/monitoring/static/js/17981.5fd12b3d.chunk.js new file mode 100644 index 000000000000..c0aac816dafc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/17981.5fd12b3d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[17981],{17981:(e,n,r)=>{r.d(n,{default:()=>i});var t=r(90160);const i=r.n(t)()},90160:e=>{function n(e){!function(e){e.languages.ruby=e.languages.extend("clike",{comment:{pattern:/#.*|^=begin\s[\s\S]*?^=end/m,greedy:!0},"class-name":{pattern:/(\b(?:class|module)\s+|\bcatch\s+\()[\w.\\]+|\b[A-Z_]\w*(?=\s*\.\s*new\b)/,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:BEGIN|END|alias|and|begin|break|case|class|def|define_method|defined|do|each|else|elsif|end|ensure|extend|for|if|in|include|module|new|next|nil|not|or|prepend|private|protected|public|raise|redo|require|rescue|retry|return|self|super|then|throw|undef|unless|until|when|while|yield)\b/,operator:/\.{2,3}|&\.|===||[!=]?~|(?:&&|\|\||<<|>>|\*\*|[+\-*/%<>!^&|=])=?|[?:]/,punctuation:/[(){}[\].,;]/}),e.languages.insertBefore("ruby","operator",{"double-colon":{pattern:/::/,alias:"punctuation"}});var n={pattern:/((?:^|[^\\])(?:\\{2})*)#\{(?:[^{}]|\{[^{}]*\})*\}/,lookbehind:!0,inside:{content:{pattern:/^(#\{)[\s\S]+(?=\}$)/,lookbehind:!0,inside:e.languages.ruby},delimiter:{pattern:/^#\{|\}$/,alias:"punctuation"}}};delete e.languages.ruby.function;var r="(?:"+[/([^a-zA-Z0-9\s{(\[<=])(?:(?!\1)[^\\]|\\[\s\S])*\1/.source,/\((?:[^()\\]|\\[\s\S]|\((?:[^()\\]|\\[\s\S])*\))*\)/.source,/\{(?:[^{}\\]|\\[\s\S]|\{(?:[^{}\\]|\\[\s\S])*\})*\}/.source,/\[(?:[^\[\]\\]|\\[\s\S]|\[(?:[^\[\]\\]|\\[\s\S])*\])*\]/.source,/<(?:[^<>\\]|\\[\s\S]|<(?:[^<>\\]|\\[\s\S])*>)*>/.source].join("|")+")",t=/(?:"(?:\\.|[^"\\\r\n])*"|(?:\b[a-zA-Z_]\w*|[^\s\0-\x7F]+)[?!]?|\$.)/.source;e.languages.insertBefore("ruby","keyword",{"regex-literal":[{pattern:RegExp(/%r/.source+r+/[egimnosux]{0,6}/.source),greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}},{pattern:/(^|[^/])\/(?!\/)(?:\[[^\r\n\]]+\]|\\.|[^[/\\\r\n])+\/[egimnosux]{0,6}(?=\s*(?:$|[\r\n,.;})#]))/,lookbehind:!0,greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}}],variable:/[@$]+[a-zA-Z_]\w*(?:[?!]|\b)/,symbol:[{pattern:RegExp(/(^|[^:]):/.source+t),lookbehind:!0,greedy:!0},{pattern:RegExp(/([\r\n{(,][ \t]*)/.source+t+/(?=:(?!:))/.source),lookbehind:!0,greedy:!0}],"method-definition":{pattern:/(\bdef\s+)\w+(?:\s*\.\s*\w+)?/,lookbehind:!0,inside:{function:/\b\w+$/,keyword:/^self\b/,"class-name":/^\w+/,punctuation:/\./}}}),e.languages.insertBefore("ruby","string",{"string-literal":[{pattern:RegExp(/%[qQiIwWs]?/.source+r),greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/("|')(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|(?!\1)[^\\#\r\n])*\1/,greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?([a-z_]\w*)[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?[a-z_]\w*|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?/}},interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?'([a-z_]\w*)'[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?'[a-z_]\w*'|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?'|'$/}},string:/[\s\S]+/}}],"command-literal":[{pattern:RegExp(/%x/.source+r),greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}},{pattern:/`(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|[^\\`#\r\n])*`/,greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}}]}),delete e.languages.ruby.string,e.languages.insertBefore("ruby","number",{builtin:/\b(?:Array|Bignum|Binding|Class|Continuation|Dir|Exception|FalseClass|File|Fixnum|Float|Hash|IO|Integer|MatchData|Method|Module|NilClass|Numeric|Object|Proc|Range|Regexp|Stat|String|Struct|Symbol|TMS|Thread|ThreadGroup|Time|TrueClass)\b/,constant:/\b[A-Z][A-Z0-9_]*(?:[?!]|\b)/}),e.languages.rb=e.languages.ruby}(e)}e.exports=n,n.displayName="ruby",n.aliases=["rb"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1836.f49bfd4f.chunk.js b/ydb/core/viewer/monitoring/static/js/1836.f49bfd4f.chunk.js deleted file mode 100644 index 5325adfd2149..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1836.f49bfd4f.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1836],{81836:(e,t,i)=>{i.r(t),i.d(t,{default:()=>P});var s=i(59284),n=i(23936),o=i.n(n),l=i(905),r=i.n(l),a=i(8964),u=i(42392),c=i(22680),d=i(14750),h=i(68724),f=i(17148),p=i.n(f),g=i(66643);function m(e){const t=document.createElement("span");return t.innerText=e,t.innerHTML}const _="data-series-name",v="data-series-idx",y="_tooltip",b="_tooltip-row",w=()=>"",E=e=>`\n
\n `,S=e=>`\n ${e.hideSeriesName?"":m(e.seriesName)}\n `,x=e=>`\n ${e.percentValue?e.percentValue+"%":""}\n `,A=e=>`\n ${e.value}\n `,T=e=>`\n ${e.diff?` (${e.diff})`:""}\n `,O=(e,t=!1,i=1)=>`\n ${e.holiday?`
\n
\ud83c\udf88
\n
\n ${e.holidayText}\n ${e.region?`[${e.region}]`:""}\n
\n
`:""}\n\n ${e.commentDateText?`
${e.commentDateText}
`:""}\n\n ${e.xComments?e.xComments.map((e=>`
${e.text}
`)).join(""):""}\n `,L=(e,{isSelectedLine:t,cellsRenderers:i,isSingleLine:s,allowComment:n,withDarkBackground:o,rowIndex:l})=>{const r=e.commentText||e.xyCommentText,a=n&&r,u=i.slice(),c=`${String(l)||""}-${String(m(e.seriesName)).slice(0,20).replace(/(\r\n|\n|\r)/gm,"")}`;return e.insertCellAt&&(Object.keys(e.insertCellAt)||[]).forEach((e=>{u.splice(Number(e),0,w)})),e.customRender?`\n ${0===e.customRender.trim().indexOf("${e.customRender}`}\n \n ${a?`\n \n ${e.commentText?`
${e.commentText}
`:""}\n ${e.xyCommentText?`
${e.xyCommentText}
`:""}\n \n `:""}`:`\n ${u.map(((t,i)=>e.replaceCellAt&&e.replaceCellAt[i]?"string"===typeof e.replaceCellAt[i]?e.replaceCellAt[i]:e.replaceCellAt[i](e):e.insertCellAt&&e.insertCellAt[i]?"string"===typeof e.insertCellAt[i]?e.insertCellAt[i]:e.insertCellAt[i](e):t(e))).join("")}\n \n\n ${a?`\n \n ${e.commentText?`
${e.commentText}
`:""}\n ${e.xyCommentText?`
${e.xyCommentText}
`:""}\n \n `:""}`},I=(e,t)=>{const{splitTooltip:i,activeRowAlwaysFirstInTooltip:s}=e,n=e.lines.findIndex((({selectedSeries:e})=>e)),o=e.lines[n],l=e.lines.slice(0,(t.lastVisibleRowIndex||e.lines.length)+1),r=[];r.push(E),e.shared&&r.push(S),e.withPercent&&r.push(x),r.push(A),e.useCompareFrom&&r.push(T);const u={isSingleLine:1===l.length,cellsRenderers:r},c={cellsRenderers:r,useCompareFrom:e.useCompareFrom,isSelectedLine:!0,allowComment:n>t.lastVisibleRowIndex},d=document.body.clientHeight/(window.visualViewport&&window.visualViewport.scale||1);let h=y;return i&&(h+=` ${y}_split-tooltip`),`\n
\n ${e.tooltipHeader?`
\n ${e.tooltipHeader.trim()}\n
`:""}\n ${i&&(e.holiday||e.commentDateText||e.xComments&&e.xComments.length)?`\n \n \n ${O(e,!0,r.length)}\n \n \n
`:""}\n \n \n \n\n ${!i&&(e.holiday||e.commentDateText||e.xComments&&e.xComments.length)?O(e):""}\n \n
\n \n ${i?"":`\n ${o&&(s||t.lastVisibleRowIndex&&n>t.lastVisibleRowIndex)?L(o,c):""}\n ${Array(r.length).fill("").join("")}\n `}\n \n ${l.map(((e,t)=>L(e,function(e){return Object.assign(Object.assign({},u),{rowIndex:e,isSelectedLine:l.length>1&&e===n,withDarkBackground:l.length>2&&Boolean(e%2),allowComment:e!==n||!c.allowComment})}(t)))).join("")}\n \n ${i?"":`\n ${t.lastVisibleRowIndex&&e.hiddenRowsNumber>0?`\n \n \n `:""}\n ${Array(r.length).fill("").join("")}\n ${e.sum?`\n \n \n `:""}\n `}\n
\n ${(0,a.R)("common","tooltip-rest")} ${e.hiddenRowsNumber}\n ${e.hiddenRowsSum}
${(0,a.R)("common","tooltip-sum")}\n ${e.sum}\n
\n
\n
`},D=e=>"object"===typeof e&&null!==e?Object.values(e).reduce(((e,t)=>t)):e,M=({data:e,rowId:t})=>{const i=e.yagr.getSeriesById(t);return e.yagr.getSerieLegendColor(i)},k=(e=1,t)=>(i,s)=>{const n=(s[s.length-1]-s[0])/e;return s.map((i=>{const s=(0,d.KQ)({input:i/e,timeZone:t});return 0===s.hour()&&0===s.minute()&&0===s.second()?s.format("DD.MM.YY"):s.format(n<300?"HH:mm:ss":"HH:mm")}))},C=(e,t)=>i=>{const s=i/((null===e||void 0===e?void 0:e.timeMultiplier)||1),n=(0,d.KQ)({input:s}),o=60*(n.utcOffset()-(0,d.KQ)({input:s,timeZone:t}).utcOffset())*1e3;return new Date(n.valueOf()-o)},R=e=>{var t,i;const{data:s,libraryConfig:n,theme:o}=e,l=Object.assign(Object.assign({},n),{timeline:s.timeline,series:s.graphs}),{timeZone:r}=s,a={appearance:{locale:g.W.get("lang"),theme:o}};var u;p()(a,l.chart),l.chart=a,(null===(t=l.tooltip)||void 0===t?void 0:t.show)&&(l.tooltip=l.tooltip||{},l.tooltip.render=(null===(i=l.tooltip)||void 0===i?void 0:i.render)||(u=s,e=>{const{timeZone:t}=u,i=e.yagr.config.chart.timeMultiplier||1,s=e.options,{x:n,state:o}=e;let l=0;const r=Object.values(e.scales).reduce(((e,t)=>(l+=t.sum||0,e.concat(t.rows))),[]),a=r.length,c=D(s.sum),h=D(s.maxLines),f=D(s.value),p=o.pinned?void 0:a>h?Math.abs(h-a):void 0,g=p?f(r.slice(-p).reduce(((e,{originalValue:t})=>e+(t||0)),0)):void 0,m={activeRowAlwaysFirstInTooltip:r.length>1,tooltipHeader:(0,d.KQ)({input:n/i,timeZone:t}).format("DD MMMM YYYY HH:mm:ss"),shared:!0,lines:r.map(((t,i)=>Object.assign(Object.assign({},t),{seriesName:t.name||"Serie "+(i+1),seriesColor:M({data:e,rowId:t.id}),selectedSeries:t.active,seriesIdx:t.seriesIdx,percentValue:"number"===typeof t.transformed?t.transformed.toFixed(1):""}))),withPercent:D(s.percent),hiddenRowsNumber:p,hiddenRowsSum:g};return c&&(m.sum=f(l)),I(m,{lastVisibleRowIndex:o.pinned?r.length-1:h-1})}),l.tooltip.className||(l.tooltip.className="chartkit-yagr-tooltip"),e.customTooltip&&(l.tooltip.virtual=!0),l.tooltip.sort=l.tooltip.sort||((e,t)=>t.rowIdx-e.rowIdx)),l.axes=l.axes||{};const c=l.axes[h.defaults.DEFAULT_X_SCALE];return l.editUplotOptions=e=>Object.assign(Object.assign({},e),{tzDate:r?C(l.chart,r):void 0}),c&&!c.values&&(c.values=k(l.chart.timeMultiplier,r)),c||(l.axes[h.defaults.DEFAULT_X_SCALE]={values:k(l.chart.timeMultiplier,r)}),l},F=s.forwardRef((function(e,t){const{id:i,data:{data:n},onLoad:l,onRender:d,onChartLoad:h,tooltip:f}=e,p=s.useRef(null),[g,m]=s.useState();if(!n||r()(n))throw new u.R({code:u.iY.NO_DATA,message:(0,a.R)("error","label_no-data")});const{config:_,debug:v}=((e,t)=>{const{data:i,sources:n,libraryConfig:o}=e.data,l=(0,c.i)();return{config:s.useMemo((()=>R({data:i,libraryConfig:o,theme:l,customTooltip:Boolean(e.tooltip)})),[i,o,l,e.tooltip]),debug:s.useMemo((()=>({filename:n&&Object.values(n).map((e=>{var t;return null===(t=null===e||void 0===e?void 0:e.data)||void 0===t?void 0:t.program})).filter(Boolean).join(", ")||t})),[t,n])}})(e,i),y=s.useCallback(((e,{renderTime:t})=>{null===l||void 0===l||l(Object.assign(Object.assign({},n),{widget:e,widgetRendering:t})),null===d||void 0===d||d({renderTime:t}),m(e)}),[l,d,n,m]),b=s.useCallback((()=>{g&&g.reflow()}),[]);return s.useImperativeHandle(t,(()=>({reflow(){b()}})),[b]),s.useEffect((()=>{var e,t,i,s,n;if(!g||(null===(t=null===(e=g.config)||void 0===e?void 0:e.tooltip)||void 0===t?void 0:t.virtual))return;const o={mouseMove:null,mouseDown:null};null===(i=g.plugins.tooltip)||void 0===i||i.on("render",(e=>{(e=>{const t=e.querySelector("._tooltip-header"),i=e.querySelector("._tooltip-list");if(!t||!i||!t.children.length)return;const s=t.children[0];for(let a=0;ai.children[0].getBoundingClientRect().width?t:i,l=Array.prototype.reduce.call(o.children[0].children,((e,t)=>(e.push(t.getBoundingClientRect().width),e)),[]),r=(o===t?i:t).children[0];for(let a=0;a{var i;o.mouseMove=(i={tooltip:e,yagr:g},e=>{var t;const{tooltip:s,yagr:n}=i;if(!n)return;const o=e.target,l=o&&s.contains(o)&&"TD"===o.tagName?null===(t=o.parentElement)||void 0===t?void 0:t.dataset.seriesIdx:void 0,r=l?n.uplot.series[Number(l)]:null;n.setFocus(r?r.id:null,!0)}),o.mouseDown=(e=>t=>{var i;const{tooltip:s,actions:n,yagr:o}=e;if(!o)return;const l=t.target;if(l instanceof Element){const e=l&&s.contains(l),t=l&&(null===(i=o.root.querySelector(".u-over"))||void 0===i?void 0:i.contains(l));e||t||(n.pin(!1),n.hide())}})({tooltip:e,actions:t,yagr:g}),document.addEventListener("mousemove",o.mouseMove),document.addEventListener("mousedown",o.mouseDown)})),null===(n=g.plugins.tooltip)||void 0===n||n.on("unpin",(()=>{o.mouseMove&&(document.removeEventListener("mousemove",o.mouseMove),o.mouseMove=null),o.mouseDown&&(document.removeEventListener("mousedown",o.mouseDown),o.mouseDown=null)}))}),[g]),s.useLayoutEffect((()=>{null===h||void 0===h||h({widget:g})}),[g,h]),s.createElement(s.Fragment,null,f&&g&&f({yagr:g}),s.createElement(o(),{ref:p,id:i,config:_,debug:v,onChartLoad:y}))})),P=F},46976:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.TIME_MULTIPLIER=t.TOOLTIP_DEFAULT_MAX_LINES=t.TOOLTIP_X_OFFSET=t.TOOLTIP_Y_OFFSET=t.MIN_SELECTION_WIDTH=t.CURSOR_STYLE=t.MARKER_DIAMETER=t.SERIE_AREA_BORDER_WIDTH=t.SERIE_AREA_BORDER_COLOR=t.SERIE_LINE_WIDTH=t.SERIE_COLOR=t.PADDING_BOTH=t.PADDING_RIGHT=t.PADDING_LEFT=t.BARS_DRAW_MAX=t.BARS_DRAW_FACTOR=t.TYPES_ORDER=t.X_AXIS_INCRS=t.X_AXIS_SPACE=t.X_AXIS_SIZE=t.X_AXIS_TICK_GAP=t.DECADE=t.YEAR=t.DAY=t.HOUR=t.MINUTE=t.SECOND=t.Y_AXIS_LABEL_SIZE=t.Y_AXIS_SIZE=t.DEFAULT_Y_AXIS_LABEL_PADDING=t.DEFAULT_Y_AXIS_PADDING=t.DEFAULT_Y_AXIS_SIZE=t.Y_AXIS_TICK_GAP=t.AXIS_VALUES_FONT=t.AXIS_LABEL_FONT=t.DEFAULT_AXIS_FONT_SIZE=t.DARK_DEFAULT_LINE_COLOR=t.LIGHT_DEFAULT_LINE_COLOR=t.DEFAULT_TITLE_FONT_SIZE=t.DEFAULT_SYNC_KEY=t.DEFAULT_POINT_SIZE=t.DEFAULT_LOGARITHMIC_MIN_SCALE_VALUE=t.DEFAULT_SCALE_MIN_RANGE=t.DEFAULT_Y_AXIS_OFFSET=t.DEFAULT_MAX_TICKS=t.DEFAULT_CANVAS_PIXEL_RATIO=t.DEFAULT_FOCUS_ALPHA=t.DEFAULT_Y_SCALE=t.DEFAULT_X_SCALE=t.DEFAULT_X_SERIE_NAME=void 0,t.DEFAULT_X_SERIE_NAME="date",t.DEFAULT_X_SCALE="x",t.DEFAULT_Y_SCALE="y",t.DEFAULT_FOCUS_ALPHA=.3,t.DEFAULT_CANVAS_PIXEL_RATIO="undefined"===typeof window?1:window.devicePixelRatio,t.DEFAULT_MAX_TICKS=5,t.DEFAULT_Y_AXIS_OFFSET=.05,t.DEFAULT_SCALE_MIN_RANGE=.01,t.DEFAULT_LOGARITHMIC_MIN_SCALE_VALUE=.001,t.DEFAULT_POINT_SIZE=t.DEFAULT_CANVAS_PIXEL_RATIO>=2?4:2,t.DEFAULT_SYNC_KEY="sync",t.DEFAULT_TITLE_FONT_SIZE=14,t.LIGHT_DEFAULT_LINE_COLOR="#222222",t.DARK_DEFAULT_LINE_COLOR="#eeeeee",t.DEFAULT_AXIS_FONT_SIZE=11,t.AXIS_LABEL_FONT="normal 11px Lucida Grande, Arial, Helvetica, sans-serif",t.AXIS_VALUES_FONT="11px Lucida Grande, Arial, Helvetica, sans-serif",t.Y_AXIS_TICK_GAP=6,t.DEFAULT_Y_AXIS_SIZE=12,t.DEFAULT_Y_AXIS_PADDING=12,t.DEFAULT_Y_AXIS_LABEL_PADDING=2;t.Y_AXIS_SIZE=(e,i,s)=>{if(!i)return t.DEFAULT_Y_AXIS_SIZE;const n=i.reduce(((e,t)=>e.length>t.length?e:t)),{ctx:o}=e;o.save();const l=e.axes[s];o.font=l.font?l.font[0]:t.AXIS_VALUES_FONT;const{width:r}=o.measureText(n);o.restore();let a=0;if(l.label){a=l.labelSize||t.DEFAULT_AXIS_FONT_SIZE,o.font=l.labelFont?l.labelFont[0]:t.AXIS_LABEL_FONT;const{fontBoundingBoxAscent:e}=o.measureText(l.label);a=e,o.restore()}return a?r/t.DEFAULT_CANVAS_PIXEL_RATIO+a/t.DEFAULT_CANVAS_PIXEL_RATIO+t.DEFAULT_Y_AXIS_LABEL_PADDING:r/t.DEFAULT_CANVAS_PIXEL_RATIO+t.DEFAULT_Y_AXIS_PADDING},t.Y_AXIS_LABEL_SIZE=11,t.SECOND=1e3,t.MINUTE=60*t.SECOND,t.HOUR=60*t.MINUTE,t.DAY=24*t.HOUR,t.YEAR=365*t.DAY,t.DECADE=10*t.YEAR,t.X_AXIS_TICK_GAP=6,t.X_AXIS_SIZE=32,t.X_AXIS_SPACE=80,t.X_AXIS_INCRS=[1,10,50,100,200,500,t.SECOND,2*t.SECOND,5*t.SECOND,10*t.SECOND,15*t.SECOND,30*t.SECOND,t.MINUTE,5*t.MINUTE,10*t.MINUTE,30*t.MINUTE,t.HOUR,2*t.HOUR,3*t.HOUR,4*t.HOUR,6*t.HOUR,12*t.HOUR,t.DAY,2*t.DAY,3*t.DAY,5*t.DAY,10*t.DAY,15*t.DAY,30*t.DAY,60*t.DAY,120*t.DAY,180*t.DAY,t.YEAR,2*t.YEAR,5*t.YEAR,10*t.YEAR],t.TYPES_ORDER=["dots","line","area","column"],t.BARS_DRAW_FACTOR=.5,t.BARS_DRAW_MAX=100,t.PADDING_LEFT=[14,14,0,4],t.PADDING_RIGHT=[14,4,0,14],t.PADDING_BOTH=[14,4,0,4],t.SERIE_COLOR="rgba(0, 0, 0, 1)",t.SERIE_LINE_WIDTH=2,t.SERIE_AREA_BORDER_COLOR="rgba(0, 0, 0, 0.2)",t.SERIE_AREA_BORDER_WIDTH=1,t.MARKER_DIAMETER=8,t.CURSOR_STYLE="1px solid #ffa0a0",t.MIN_SELECTION_WIDTH=15;t.default=class{constructor(e,t="light"){this.setTheme(t),this.colors=e}setTheme(e){this.theme=e}get GRID(){return{show:!0,stroke:()=>this.colors.parse("--yagr-grid"),width:1}}get X_AXIS_TICKS(){return{size:8,...this.GRID}}get Y_AXIS_TICKS(){return{size:6,...this.GRID}}get AXIS_STROKE(){return this.colors.parse("--yagr-axis-stroke")}get BACKGROUND(){return this.colors.parse("--yagr-background")}get SHIFT(){var e;return(null===(e=this.theme)||void 0===e?void 0:e.startsWith("light"))?.68:-.6}get DEFAULT_LINE_COLOR(){var e;return(null===(e=this.theme)||void 0===e?void 0:e.startsWith("light"))?t.LIGHT_DEFAULT_LINE_COLOR:t.DARK_DEFAULT_LINE_COLOR}},t.TOOLTIP_Y_OFFSET=24,t.TOOLTIP_X_OFFSET=24,t.TOOLTIP_DEFAULT_MAX_LINES=10,t.TIME_MULTIPLIER=1},37100:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t},l=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0});const r=l(i(16381)),a=l(i(72168)),u=i(50497),c=l(i(20500)),d=o(i(46976)),h=l(i(576)),f=i(2836),p=i(78229),g=i(65781),m=i(87102),_=i(32532);class v{get isEmpty(){return this.state.isEmptyDataSet}constructor(e,t){this.plugins={},this._meta={},this._uHooks={},this.init=()=>{var e;(null===(e=this.config.chart.size)||void 0===e?void 0:e.adaptive)&&!this.resizeOb&&(this.resizeOb=new ResizeObserver((0,u.debounce)(this.onResize,this.config.chart.size.resizeDebounceMs||100)),this.resizeOb.observe(this.root)),this.config.hooks.dispose||(this.config.hooks.dispose=[]),this.unsubscribe(),this.config.hooks.dispose.push(this.trackMouse())},this.execHooks=(e,...t)=>{const i=this.config.hooks[e];if(Array.isArray(i))for(const s of i)s&&"function"===typeof s&&s(...t)},this.initRender=(e,t)=>{var i,s,n;const o=null===(i=this.config.legend)||void 0===i?void 0:i.position;this.root.firstChild?o&&"bottom"!==o?this.root.appendChild(e.root):this.root.insertBefore(e.root,this.root.firstChild):o&&"bottom"!==o?this.root.insertBefore(e.root,this.root.firstChild):this.root.appendChild(e.root),(null===(s=this.config.legend)||void 0===s?void 0:s.show)&&(null===(n=this.plugins.legend)||void 0===n||n.init(e),this.reflow(!1)),this.initTitle(),t()},this.onResize=e=>{var t;const[i]=e;this._cache.height===i.contentRect.height&&this._cache.width===i.contentRect.width||(null===(t=this.plugins.tooltip)||void 0===t||t.reset(),this.reflow(),this.execHooks("resize",{entries:e,chart:this}))},this.initMixins(),this._startTime=performance.now(),this.state={isEmptyDataSet:!1,isMouseOver:!1,stage:"config",y2uIdx:{},subscribed:!1};const i=Object.assign({title:{},data:[],axes:{},series:[],scales:{},hooks:{},settings:{},chart:{},cursor:{},plugins:{},legend:{show:!1},tooltip:{show:!0},grid:null,markers:{}},t);this.config=i,this.inStage("config",(()=>{var t;this.id=e.id||(0,u.genId)(),this.root=e,this.root.classList.add("yagr"),this.root.id||(this.root.id=this.id);const s=new c.default,n=this.config.cursor.sync,o=this.config.chart;o.series||(o.series={type:"line"}),o.size||(o.size={adaptive:!0}),o.appearance||(o.appearance={locale:"en"}),o.select||(o.select={}),this.utils={colors:s,i18n:(0,h.default)((null===(t=i.chart.appearance)||void 0===t?void 0:t.locale)||"en"),theme:new d.default(s)},s.setContext(e),n&&(this.utils.sync=r.default.sync("string"===typeof n?n:d.DEFAULT_SYNC_KEY)),!o.size.adaptive&&o.size.width&&o.size.height&&(e.style.width=(0,u.px)(o.size.width),e.style.height=(0,u.px)(o.size.height)),this.plugins.legend=new a.default,this.setTheme(o.appearance.theme||"light"),this.createUplotOptions(),this._cache={height:this.options.height,width:this.options.width},i.editUplotOptions&&(this.options=i.editUplotOptions(this.options))})).inStage("processing",(()=>{this.transformSeries()})).inStage("uplot",(()=>{this.uplot=new r.default(this.options,this.series,this.initRender),this.canvas=e.querySelector("canvas"),this.init();const t=performance.now()-this._startTime;this._meta.processTime=t})).inStage("render")}redraw(e=!0,t=!0){this.uplot.redraw(e,t)}getSeriesById(e){return this.uplot.series[this.state.y2uIdx[e]]}getSerieLegendColor(e){const{legendColorKey:t,color:i,lineColor:s}=e;let n=i;switch(t){case"lineColor":s&&(n=s);break;case"color":n=i}return n}dispose(){var e,t,i,s;this.resizeOb&&this.resizeOb.unobserve(this.root),this.unsubscribe(),null===(t=null===(e=this.plugins)||void 0===e?void 0:e.tooltip)||void 0===t||t.dispose(),null===(s=null===(i=this.plugins)||void 0===i?void 0:i.legend)||void 0===s||s.destroy(),this.uplot.destroy(),this._uHooks={},this.execHooks("dispose",{chart:this})}toDataUrl(){return this.canvas.toDataURL("img/png")}subscribe(){var e;this.state.subscribed||(null===(e=this.utils.sync)||void 0===e||e.sub(this.uplot),this.state.subscribed=!0)}unsubscribe(){var e;null===(e=this.utils.sync)||void 0===e||e.unsub(this.uplot),this.state.subscribed=!1}inStage(e,t){this.state.stage,this.execHooks("stage",{chart:this,stage:e});try{t&&t()}catch(i){console.error(i),this.onError(i)}return this}initTitle(){if(this.config.title&&this.config.title.fontSize){const e=this.config.title.fontSize,t=this.root.querySelector(".u-title");t.setAttribute("style",`font-size:${e}px;line-height:${e}px;`),t.innerHTML=this.config.title.text}}onError(e){return this.execHooks("error",{stage:this.state.stage,error:e,chart:this}),e}trackMouse(){const e=()=>{this.state.isMouseOver=!0},t=()=>{this.state.isMouseOver=!1};return this.root.addEventListener("mouseover",e),this.root.addEventListener("mouseleave",t),()=>{this.root.removeEventListener("mouseover",e),this.root.removeEventListener("mouseleave",t)}}get clientHeight(){var e;const t=this.config.title.text?(this.config.title.fontSize||d.DEFAULT_TITLE_FONT_SIZE)+8:0;return this.root.clientHeight-t-((null===(e=this.plugins.legend)||void 0===e?void 0:e.state.totalSpace)||0)}reflow(e=!0){const t=this.root.clientWidth,i=this.clientHeight;this._cache.width=t,this.options.width=t,this._cache.height=i,this.options.height=i,e&&this.uplot.setSize({width:this.options.width,height:this.options.height}),e&&this.uplot.redraw()}}(0,m.applyMixins)(v,[f.CreateUplotOptionsMixin,p.TransformSeriesMixin,g.DynamicUpdatesMixin,_.BatchMixin]),t.default=v},576:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0});const i={ru:{"hide-all":"\u0421\u043a\u0440\u044b\u0442\u044c \u0432\u0441\u0435","show-all":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435",sum:"\u0421\u0443\u043c\u043c\u0430",scale:"\u0428\u043a\u0430\u043b\u0430",series:"\u041b\u0438\u043d\u0438\u044f",weekend:"\u0412\u044b\u0445\u043e\u0434\u043d\u043e\u0439",nodata:"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445"},en:{"hide-all":"Hide all","show-all":"Show all",sum:"Total",scale:"Scale",series:"Series",weekend:"Weekend",nodata:"No data"}};t.default=(e="en")=>("string"!==typeof e&&(i.custom=e,e="custom"),t=>i[e][t]||t)},32532:function(e,t,i){var s=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.BatchMixin=void 0;const n=s(i(16381)),o=s(i(72168));t.BatchMixin=class{initMixin(){this._batch={active:!1,fns:[]}}batch(e){var t;return this._batch.active?e(this._batch):(this._batch.active=!0,e(this._batch),this._batch.reinit?this.fullUpdate():(this._batch.redrawLegend&&(null===(t=this.plugins.legend)||void 0===t||t.redraw()),this._batch.reopt&&this.createUplotOptions(!0),this._batch.recalc&&this.inStage("processing",(()=>{this.transformSeries()})).inStage("listen"),this._batch.fns.length&&this.uplot.batch((()=>this._batch.fns.forEach((e=>e(this._batch))))),this._batch.redraw&&this.uplot&&this.redraw(...this._batch.redraw),void(this._batch={active:!1,fns:[]})))}fullUpdate(){let e,t;this.inStage("dispose",(()=>{var i;if(this.uplot){const i=this.uplot.cursor;e=i.left,t=i.top,this.uplot.destroy()}null===(i=this.plugins.legend)||void 0===i||i.destroy()})).inStage("config",(()=>{this.plugins.legend=new o.default,this._batch={active:!1,fns:[]},this.createUplotOptions(!0),this.options=this.config.editUplotOptions?this.config.editUplotOptions(this.options):this.options})).inStage("processing",(()=>{this.transformSeries()})).inStage("uplot",(()=>{this.uplot=new n.default(this.options,this.series,this.initRender),e&&t&&e>0&&t>0&&this.uplot.setCursor({left:e,top:t}),this.state.subscribed||this.unsubscribe()})).inStage("listen")}}},2836:function(e,t,i){var s=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.CreateUplotOptionsMixin=void 0;const n=s(i(25700)),o=s(i(60758)),l=i(46976),r=i(28265),a=s(i(67903)),u=i(81891),c=i(24793),d=i(27658),h=i(48643),f=s(i(15648));function p(e,t){for(const i of e||[])if(i===t)return;null===e||void 0===e||e.push(t)}t.CreateUplotOptionsMixin=class{initMixin(){this._uHooks.onDraw=()=>{if("listen"===this.state.stage)return;this.state.stage="listen",this.execHooks("stage",{chart:this,stage:this.state.stage});const e=performance.now()-this._startTime;this._meta.renderTime=e,this.execHooks("load",{chart:this,meta:this._meta})},this._uHooks.ready=()=>{const e=performance.now()-this._startTime;this._meta.initTime=e,this.execHooks("inited",{chart:this,meta:{initTime:e}})},this._uHooks.drawClear=e=>{const{ctx:t}=e;t.save(),t.fillStyle=this.utils.theme.BACKGROUND,t.fillRect(l.DEFAULT_CANVAS_PIXEL_RATIO,l.DEFAULT_CANVAS_PIXEL_RATIO,e.width*l.DEFAULT_CANVAS_PIXEL_RATIO-2*l.DEFAULT_CANVAS_PIXEL_RATIO,e.height*l.DEFAULT_CANVAS_PIXEL_RATIO-2*l.DEFAULT_CANVAS_PIXEL_RATIO),t.restore()},this._uHooks.setSelect=e=>{const{left:t,width:i}=e.select,[s,n]=[e.posToVal(t,l.DEFAULT_X_SCALE),e.posToVal(t+i,l.DEFAULT_X_SCALE)],{timeMultiplier:o=l.TIME_MULTIPLIER}=this.config.chart||{};this.execHooks("onSelect",{from:Math.ceil(s/o),to:Math.ceil(n/o),chart:this}),e.setSelect({width:0,height:0,top:0,left:0},!1)}}createUplotOptions(e=!1){var t,i,s,g,m,_,v,y,b,w,E;const{config:S}=this,x=[];let A=null===(t=this.plugins)||void 0===t?void 0:t.tooltip;if(S.tooltip&&!1!==S.tooltip.show&&(A?A.updateOptions(S.tooltip):A=(0,n.default)(this,S.tooltip),x.push(A.uplot),this.plugins.tooltip=A),e)this.plugins.plotLines&&x.push(this.plugins.plotLines.uplot);else{const e=(0,f.default)(this.config.plotLines||{})(this);this.plugins.plotLines=e,x.push(e.uplot)}Object.entries(S.plugins).forEach((([e,t])=>{const i=t(this);x.push(i.uplot),Object.assign(this.plugins,{[e]:i})}));const T=S.chart,O={width:this.root.clientWidth,height:this.clientHeight,title:null===(i=S.title)||void 0===i?void 0:i.text,plugins:x,focus:{alpha:l.DEFAULT_FOCUS_ALPHA},series:[{id:l.DEFAULT_X_SERIE_NAME,$c:S.timeline,scale:l.DEFAULT_X_SCALE,count:S.timeline.length}],ms:T.timeMultiplier||l.TIME_MULTIPLIER,hooks:S.hooks||{}};if(this.state.isEmptyDataSet=0===S.timeline.length||0===S.series.length||S.series.every((({data:e})=>0===e.length)),O.cursor=O.cursor||{},O.cursor.points=O.cursor.points||{},O.cursor.drag=O.cursor.drag||{dist:(null===(s=T.select)||void 0===s?void 0:s.minWidth)||l.MIN_SELECTION_WIDTH,x:null===(g=O.cursor.y)||void 0===g||g,y:null!==(m=O.cursor.y)&&void 0!==m&&m,setScale:null===(v=null===(_=T.select)||void 0===_?void 0:_.zoom)||void 0===v||v},this.utils.sync&&(O.cursor.sync=O.cursor.sync||{key:this.utils.sync.key}),S.cursor){const e=(0,o.default)(this,S.cursor);this.plugins.cursor=e,x.push(e.uplot)}const L=S.series||[],I=O.series;for(let n=L.length-1;n>=0;n--){const e=(0,r.configureSeries)(this,L[n]||{},n),t=I.push(e);this.state.y2uIdx[e.id||n]=t-1}const D=(0,a.default)(this,S);x.push(D),O.series=I,S.scales&&0!==Object.keys(S.scales).length||(S.scales={x:{},y:{}}),O.scales=O.scales||{},O.scales=(0,u.configureScales)(this,O.scales,S),O.axes=O.axes||[];return O.axes.push(...(0,c.configureAxes)(this,S)),O.hooks=S.hooks||{},O.hooks.draw=O.hooks.draw||[],O.hooks.ready=O.hooks.ready||[],O.hooks.drawClear=O.hooks.drawClear||[],O.hooks.setSelect=O.hooks.setSelect||[],p(O.hooks.draw,this._uHooks.onDraw),p(O.hooks.ready,this._uHooks.ready),p(O.hooks.drawClear,this._uHooks.drawClear),p(O.hooks.setSelect,this._uHooks.setSelect),O.drawOrder=(null===(y=T.appearance)||void 0===y?void 0:y.drawOrder)?null===(b=T.appearance)||void 0===b?void 0:b.drawOrder.filter((e=>e===h.DrawOrderKey.Series||e===h.DrawOrderKey.Axes)):[h.DrawOrderKey.Series,h.DrawOrderKey.Axes],O.legend={show:!1},O.padding=(null===(w=S.chart.size)||void 0===w?void 0:w.padding)||(0,d.getPaddingByAxes)(O),null===(E=this.plugins.legend)||void 0===E||E.preInit(this,this.config.legend,O),O.height=this.clientHeight,this.options=O,O}}},65781:function(e,t,i){var s=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.DynamicUpdatesMixin=void 0;const n=s(i(576)),o=i(46976),l=i(28265),r=i(24793),a=i(50497);function u(e,t,i,s=!1){var n,o,l,r,u,c,d,h,f,p,g,m;if(s)return e.config={...e.config,...i},void(t.reinit=!0);const _=function(e,t){return function(i,s){const n=(0,a.get)(e,i),o=(0,a.get)(t,i);return s?!s(n,o):n!==o}}(e.config,i);i.title&&_("title")&&e.setTitle(i.title),(null===(o=null===(n=i.chart)||void 0===n?void 0:n.appearance)||void 0===o?void 0:o.theme)&&_("chart.appearance.theme")&&e.setTheme(null===(r=null===(l=i.chart)||void 0===l?void 0:l.appearance)||void 0===r?void 0:r.theme),(null===(c=null===(u=i.chart)||void 0===u?void 0:u.appearance)||void 0===c?void 0:c.locale)&&_("chart.appearance.locale")&&e.setLocale(null===(h=null===(d=i.chart)||void 0===d?void 0:d.appearance)||void 0===h?void 0:h.locale),i.axes&&_("axes",a.deepIsEqual)&&e.setAxes(i.axes),i.scales&&_("scales",a.deepIsEqual)&&e.setScales(i.scales);Boolean(i.series)&&function(e,t){if(e.length!==(null===t||void 0===t?void 0:t.length))return!0;const i=new Map,s=new Map;return e.forEach((e=>{i.set(e.id,e)})),t.forEach((e=>{s.set(e.id,e)})),!(!t.some((({id:e})=>!i.has(e)))&&!e.some((({id:e})=>!s.has(e))))}(e.config.series,i.series)&&(t.redrawLegend=!0),(i.series||i.timeline)&&e.setSeries(null!==(f=i.timeline)&&void 0!==f?f:e.config.timeline,null!==(p=i.series)&&void 0!==p?p:e.config.series,{incremental:!1}),i.tooltip&&_("tooltip")&&(null===(g=e.plugins.tooltip)||void 0===g||g.updateOptions(i.tooltip)),i.legend&&_("legend")&&(t.reinit=!0),null===(m=e.plugins.tooltip)||void 0===m||m.reset(),t.reopt=!0,e.config={...e.config,...i}}function c(e,t,i,s={incremental:!0,splice:!1}){let n,o=[],r=[],a=null,u=!1,c=!1;if(["number","string"].includes(typeof t)?(u=!1,n=!1,r=[i],a=t):"number"===typeof t[0]?(o=t,r=i,u=Boolean(s.incremental),n=!s.incremental):(r=t,n=!0),this.isEmpty&&r.some((({data:e})=>null===e||void 0===e?void 0:e.length)))e.reinit=!0;else{if(!1===n){let t=!1;if(u&&this.config.timeline.push(...o),r.forEach((i=>{var s,n;let o="number"===typeof a?this.config.series[0]:this.config.series.find((({id:e})=>e===i.id||e===a)),r=null===o||void 0===o?void 0:o.id;if("number"===typeof a&&this.state.y2uIdx[a]&&(o=this.config.series[a],r=a),o&&r){const{data:a,...d}=i,h=this.state.y2uIdx[r];"dots"!==o.type&&"dots"!==i.type&&"dots"!==(null===(s=this.config.chart.series)||void 0===s?void 0:s.type)||(e.reinit=!0),u?o.data=a?o.data.concat(a):o.data:(null===a||void 0===a?void 0:a.length)&&(o.data=a,c=!0);const f=(0,l.configureSeries)(this,Object.assign(o,d),h),p=this.options.series[h],g=this.uplot.series[h];g.show!==f.show&&e.fns.push((()=>{this.uplot.setSeries(h,{show:f.show})})),null!==g._focus&&g._focus===f.focus||e.fns.push((()=>{this.uplot.setSeries(h,{focus:f.focus})})),g.color!==f.color&&(t=!0),f.scale&&(null===(n=this.config.scales[f.scale])||void 0===n?void 0:n.stacking)&&(c=!0),(0,l.overrideSeriesInUpdate)(p,f),(0,l.overrideSeriesInUpdate)(g,f)}else e.fns.push((()=>{const e=(0,l.configureSeries)(this,i,this.config.series.length);this.state.y2uIdx[e.id]=this.uplot.series.length,this.uplot.addSeries(e,this.config.series.length)})),this.config.series.push(i)})),t&&e.fns.push((()=>{var e;null===(e=this.plugins.cursor)||void 0===e||e.updatePoints()})),s.splice){const e=r[0].data.length;this.config.series.forEach((t=>{t.data.splice(0,e)})),this.config.timeline.splice(0,o.length)}}else this.config.timeline=o,this.config.series=r,e.reinit=!0;e.reinit||(this._batch.fns.push((()=>{var e,t;return null===(t=null===(e=this.plugins)||void 0===e?void 0:e.tooltip)||void 0===t?void 0:t.reset()})),(c||o.length)&&(e.recalc=!0,e.fns.push((()=>{this.uplot.setData(this.series)}))))}}t.DynamicUpdatesMixin=class{setLocale(e){this.batch((t=>function(e,t,i){e.utils.i18n=(0,n.default)(i),t.redrawLegend=!0}(this,t,e)))}setTitle(e){this.batch((t=>{this.config.title=e,this.initTitle(),t.redraw=[!0,!0]}))}setTheme(e){this.batch((t=>function(e,t,i){e.utils.theme.setTheme(t);const s=["light","light-hc","dark","dark-hc"].map((e=>`yagr_theme_${e}`));e.root.classList.remove(...s),e.root.classList.add("yagr_theme_"+t),i.redraw=[!1,!0]}(this,e,t)))}setAxes(e){this.batch((t=>function(e,t,i){const{x:s,...n}=i;if(s){const t=e.uplot.axes.find((({scale:e})=>e===o.DEFAULT_X_SCALE));t&&(0,r.updateAxis)(e,t,{scale:o.DEFAULT_X_SCALE,...s})}Object.entries(n).forEach((([t,i])=>{const s=e.uplot.axes.find((({scale:e})=>e===t));s&&(0,r.updateAxis)(e,s,{scale:t,...i})})),t.redraw=(0,r.getRedrawOptionsForAxesUpdate)(i)}(this,t,e)))}setSeries(e,t,i={incremental:!0,splice:!1}){this.batch((s=>c.call(this,s,e,t,i)))}setFocus(e,t){this.batch((()=>function(e,t,i){var s;const n=null===t?null:e.state.y2uIdx[t];null===(s=e.plugins.cursor)||void 0===s||s.focus(n,i),e.uplot.setSeries(n,{focus:i})}(this,e,t)))}setVisible(e,t,i=!0){this.batch((s=>function(e,t,i,s,n){const l=null===t?null:e.state.y2uIdx[t];(null===t?e.config.series:[e.config.series.find((({id:e})=>e===t))]).forEach((e=>{e&&(e.show=i)})),n.fns.push((()=>{e.uplot.setSeries(l,{show:i})})),e.options.series=e.uplot.series;let r=!1;if(l){const t=e.uplot.series[l];t.show=i;const s=t.scale||o.DEFAULT_Y_SCALE,n=e.config.scales[s];r=Boolean(n&&n.stacking)}else r=e.options.series.reduce(((t,s)=>{var n;const{scale:o}=s;return s.show=i,Boolean(o&&(null===(n=e.config.scales[o])||void 0===n?void 0:n.stacking)||t)}),!1);r&&(n.recalc=!0,n.fns.push((()=>{var t;e.uplot.setData(e.series,!0),s&&(null===(t=e.plugins.legend)||void 0===t||t.update())})))}(this,e,t,i,s)))}setScales(e){this.batch((t=>function(e,t,i){let s=!1,n=!1;Object.entries(t).forEach((([t,i])=>{const o=e.config.scales[t];if(o){const{stacking:e}=o,{stacking:t}=i;e!==t&&(s=!0),i.normalize===o.normalize&&i.normalizeBase===o.normalizeBase||(n=!0)}}));const l=Object.entries(t).every((([t,i])=>{const s=e.config.scales[t],{min:n,max:o,...l}=s,{min:r,max:u,...c}=i;return!(!1===(0,a.deepIsEqual)(c,l))&&(n!==r||o!==u)})),r=Object.keys(t).includes(o.DEFAULT_X_SCALE);if(l&&!r)return Object.entries(t).forEach((([t,s])=>{i.fns.push((()=>{e.uplot.setScale(t,{min:s.min,max:s.max})}))}));(s||n)&&(i.reinit=!0),e.config.scales=t,i.reinit=!0}(this,e,t)))}setConfig(e,t=!1){this.batch((i=>u(this,i,e,t)))}}},78229:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.TransformSeriesMixin=void 0;const s=i(46976),n=i(50497);t.TransformSeriesMixin=class{transformSeries(){const e=performance.now(),t=[],i=this.config,o=i.timeline;let l=i.processing||!1,r=this.config.series.map((({data:e})=>e));l&&l.interpolation&&(r=(0,n.preprocess)(r,o,l),l=!1);const a=Boolean(l&&l.nullValues),u=l&&l.nullValues||{},c={};for(let d=0;d{const s=e.series[t];if(s.scale===n.DEFAULT_X_SCALE)return i;const o=s.$c||e.data[t],r=o[i];return d&&r===h?(0,l.findDataIdx)(o,s,i,p,h):null===r?(0,l.findDataIdx)(o,s,i,f,null):i};return{showPoints:t=>{const i=e.uplot.over;if(!i)return;u(i,t).forEach((e=>{e.style.visibility="visible"}))},hidePoints:t=>{const i=e.uplot.over;if(!i)return;u(i,t).forEach((e=>{e.style.visibility="hidden"}))},pin:t=>{var i;const s=e.root.querySelector(".u-over");if(s)if(t){const e=document.createElement("div");e.classList.add("yagr-points-holder"),s.querySelectorAll(".yagr-point").forEach((t=>{const i=t.cloneNode(!0);e.appendChild(i);const s=i.dataset.idx;s&&(g[s]=i)})),s.appendChild(e)}else g={},null===(i=s.querySelector(".yagr-points-holder"))||void 0===i||i.remove()},updatePoints:()=>{e.root.querySelectorAll(".yagr-point").forEach((t=>{const i=Number(t.dataset.idx);if(isNaN(i))return;r(e.uplot.series[i],t)}))},focus:(e,t)=>{Object.entries(g).forEach((([i,s])=>{s.style.display=null!==e?i===String(e)&&t?"block":"none":t?"block":"none"}))},uplot:{opts:(e,i)=>{var s;i.cursor=i.cursor||{};const o=i.series.filter((e=>e.empty)).length,l=i.series.length-1,r=null!==(s=null===t||void 0===t?void 0:t.maxMarkers)&&void 0!==s?s:50;i.cursor.points={show:l-o<=r&&a,size:(e,i)=>{const s=e.series[i];return(s.cursorOptions?s.cursorOptions.markersSize:null===t||void 0===t?void 0:t.markersSize)||n.MARKER_DIAMETER}},i.cursor.dataIdx=m},hooks:{...t.hideMarkers&&{setCursor:i=>{var s,n;const o=i.cursor.idx;if(!(0,l.isNil)(o))for(let l=1;l{const i=e.root.querySelector(".u-cursor-x");i&&(t.x&&!1===t.x.visible&&(i.style.display="none"),i.style.borderRight=t.x&&t.x.style||n.CURSOR_STYLE);const s=e.root.querySelector(".u-cursor-y");s&&(t.y&&!1!==t.y.visible?s.style.borderBottom=t.y.style||n.CURSOR_STYLE:s.style.display="none")}}}}}},72168:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.hasOneVisibleLine=void 0;const s=i(46976),n=i(50497),o=i(11213),l="null";t.hasOneVisibleLine=e=>e.some((({show:e,id:t})=>t!==s.DEFAULT_X_SERIE_NAME&&e));const r=(e,i)=>i.length>3&&e((0,t.hasOneVisibleLine)(i)?"hide-all":"show-all");t.default=class{constructor(){this.pagesCount=0,this.state={page:0,pages:1,pageSize:0,rowsPerPage:1,paginated:!1,requiredSpace:0,totalSpace:0},this.itemsHtml="",this.preInit=(e,t,i)=>{this.yagr=e,this.options=Object.assign({show:!1,position:"bottom",fontSize:12,maxLegendSpace:.3,className:void 0,behaviour:"basic"},t||{}),this.calc(i)},this.init=e=>{var t;this.options.show&&(this.uplot=e,null===(t=e.root.querySelector(".u-legend"))||void 0===t||t.remove(),this.render())},this.update=()=>{this.yagr.root.querySelectorAll("[data-serie-id]").forEach((e=>{var t,i;const s=e.getAttribute("data-serie-id");if(!s||s===l)return;const n=null===(i=null===(t=this.uplot)||void 0===t?void 0:t.series[this.yagr.state.y2uIdx[s]])||void 0===i?void 0:i.show;e.classList[n?"remove":"add"]("yagr-legend__item_hidden")}))},this.measureLegend=e=>{const t=this.yagr.root,i=(0,n.html)("div",{class:"yagr-legend",style:{visibility:"hidden"}},e);t.appendChild(i);const s=i.childNodes[0].getBoundingClientRect();return i.remove(),s},this.nextPage=()=>{const{state:e}=this;this.state.page+=1,this.items&&(this.items.style.transform=`translate(0, ${-1*e.page*e.pageSize}px)`,this.renderPagination())},this.prevPage=()=>{const{state:e}=this;this.state.page-=1,this.items&&(this.items.style.transform=`translate(0, ${-1*e.page*e.pageSize}px)`,this.renderPagination())}}redraw(){this.options.show&&this.render()}destroy(){var e;this._onDestroy&&this._onDestroy(),null===(e=this.legendEl)||void 0===e||e.remove()}applyHandlers(){const{yagr:e,uplot:i}=this;if(!i)return()=>{};const s=e.root.querySelectorAll("[data-serie-id]"),n=[],a={basic:s=>()=>{const n=s.getAttribute("data-serie-id"),o=[];if(n===l){const e=!(0,t.hasOneVisibleLine)(i.series);for(let t=1;te===n));if(!e)return;o.push([e,!e.show])}o.forEach((([t,i])=>{if(t.show===i)return;const s=e.root.querySelector(`[data-serie-id="${t.id}"]`);e.setVisible(t.id,i,!1),null===s||void 0===s||s.classList[i?"remove":"add"]("yagr-legend__item_hidden")}));const a=e.root.querySelector(".yagr-legend__all-series");if(a){const e=r(this.yagr.utils.i18n,i.series);a.innerHTML=e||""}},extended:s=>{const n=(t,i)=>{const s=e.root.querySelector(`[data-serie-id="${t}"]`);e.setVisible(t,i,!1),null===s||void 0===s||s.classList[i?"remove":"add"]("yagr-legend__item_hidden")},o=e=>{this.state.startSerieRange=e;const s=i.series.filter((t=>t.id!==e.id)),o=!(0,t.hasOneVisibleLine)(s)&&!1!==e.show;i.series.forEach((t=>{const i=e.id===t.id||o;n(t.id,i)}))},l=e=>{this.state.startSerieRange||(this.state.startSerieRange=i.series[1]);const t=[];i.series.forEach(((i,s)=>{var n;i.id===e.id&&t.push(s),i.id===(null===(n=this.state.startSerieRange)||void 0===n?void 0:n.id)&&t.push(s)})),i.series.forEach(((e,i)=>{const s=i>=t[0]&&i<=t[1];n(e.id,s)}))};return e=>{const t=s.getAttribute("data-serie-id"),r=i.series.find((({id:e})=>e===t));r&&(e.preventDefault(),e.ctrlKey||e.metaKey?(e=>{n(e.id,!e.show)})(r):e.shiftKey?l(r):o(r))}}},u=t=>()=>{const i=t.getAttribute("data-serie-id");if(t.classList.contains("yagr-legend__item_hidden")||i===l)return;const s=this.yagr.uplot.series.find((({id:e})=>e===i));s&&(e.setFocus(s.id,!0),e.redraw(!0,!1))},c=()=>{e.setFocus(null,!0),e.redraw(!0,!1)};s.forEach((e=>{const t=a[this.options.behaviour||"basic"](e),i=u(e);e.addEventListener("click",t),e.addEventListener("mouseenter",i),e.addEventListener("mouseleave",c),e.addEventListener("mousedown",o.preventMouseEvents),n.push((()=>{e.removeEventListener("click",t),e.removeEventListener("mouseenter",i),e.removeEventListener("mouseleave",c),e.removeEventListener("mousedown",o.preventMouseEvents)}))}));const d=()=>n.forEach((e=>e()));return this._onDestroy=d,d}render(){var e,t;let i=!1;const{uplot:s,options:o}=this;if(!s)return;let l=this.yagr.root.querySelector(".yagr-legend");if(l?i=!0:l=(0,n.html)("div",{class:`yagr-legend yagr-legend__${this.options.position} ${(null===o||void 0===o?void 0:o.className)||""}`}),l){if(i||("top"===o.position?s.root.before(l):null===(e=s.root)||void 0===e||e.after(l)),this.legendEl=l,this.itemsHtml&&!i||this.calc(this.yagr.options),l.innerHTML=`
${this.itemsHtml}
`,this.items=l.querySelector(".yagr-legend__items"),this.container=l.querySelector(".yagr-legend__container"),this.state.paginated){const e=this.renderPagination();null===(t=this.container)||void 0===t||t.after(e)}else this.items.style.justifyContent="center";this.applyHandlers()}}renderPagination(){const{state:e}=this;let t=this.yagr.root.querySelector(".yagr-legend__pagination");if(t){const e=t.querySelector(".yagr-legend__icon-down"),i=t.querySelector(".yagr-legend__icon-up");e.removeEventListener("click",this.nextPage),i.removeEventListener("click",this.prevPage)}else t=(0,n.html)("div",{class:"yagr-legend__pagination"});const i=0===e.page?"yagr-legend__icon-up_disabled":"",s=e.page===e.pages-1?"yagr-legend__icon-down_disabled":"";t.innerHTML=`\n${e.page+1}/${e.pages}\n`;const o=t.querySelector(".yagr-legend__icon-down"),l=t.querySelector(".yagr-legend__icon-up");return s||o.addEventListener("click",this.nextPage),i||l.addEventListener("click",this.prevPage),t}createIconLineElement(e){return(0,n.html)("span",{class:`yagr-legend__icon yagr-legend__icon_${e.type}`,style:{"background-color":this.yagr.getSerieLegendColor(e)}})}createSerieNameElement(e){const t=(0,n.html)("span");return t.innerText=e.name||"unnamed",t}renderItems(e){const t=r(this.yagr.utils.i18n,e.series),i="extended"!==this.options.behaviour&&(e=>e.length>3&&l||void 0)(e.series),s=i?[i]:[];for(let n=1;n${s.map((e=>{let s,n,o=" ";if(e===l)s=t,n=i,o=" yagr-legend__all-series ";else{n=e.id;const t=this.createIconLineElement(e),i=this.createSerieNameElement(e);s=`${t.outerHTML}${i.outerHTML}`}return`
${s}
`})).join("")}`}calc(e){if(!this.options.show)return;const t=e.height-this.VERTICAL_PADDING,i=this.renderItems(e),{height:s}=this.measureLegend(i),n=this.options.fontSize+2,o=t*this.options.maxLegendSpace,l=Math.floor(o/n),r=l-1,a=Math.min(r*n,o),u=Math.min(l*n,o),c=s>a&&a>0,d=Math.min(c?u:a,s),h=Math.ceil(s/a),f=c?this.VERTICAL_PADDING+18:this.VERTICAL_PADDING;this.state.requiredSpace=d,this.state.totalSpace=d+f,this.state.paginated=c,this.state.page=this.state.page||0,this.state.pages=h,this.state.pageSize=a,this.state.rowsPerPage=l,this.itemsHtml=i}get VERTICAL_PADDING(){return"bottom"===this.options.position?20:48}}},67903:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.drawMarkersIfRequired=t.renderCircle=void 0;const s=i(46976),n=i(50497);t.renderCircle=(e,t,i,n,o,l,r,a)=>{const{ctx:u}=e,c=Math.round(e.valToPos(t,s.DEFAULT_X_SCALE,!0)),d=Math.round(e.valToPos(i,a||s.DEFAULT_Y_SCALE,!0));if(u.beginPath(),u.arc(c,d,2*n,0,2*Math.PI),u.fillStyle=l,o){const e=u.lineWidth,t=u.strokeStyle;u.lineWidth=o,u.strokeStyle=r,u.stroke(),u.lineWidth=e,u.strokeStyle=t}u.fill(),u.closePath()},t.drawMarkersIfRequired=function(e,i,o,l){const{color:r,scale:a,spanGaps:u,count:c,pointsSize:d}=e.series[i];if(u&&c>1)return!1;let h,f=o;for(;f<=l;){const o=e.data[i][f];if(null===o){h=o,f++;continue}const l=f+1,u=e.data[i][l];(0,n.isNil)(h)&&(0,n.isNil)(u)&&(0,t.renderCircle)(e,e.data[0][f],o,null!==d&&void 0!==d?d:s.DEFAULT_POINT_SIZE/2,0,r,r,a||s.DEFAULT_Y_SCALE),h=o,f++}},t.default=function(e,i){var n;const{size:o=s.DEFAULT_POINT_SIZE,strokeWidth:l=2,strokeColor:r="#ffffff",show:a}=i.markers,u=null===(n=i.chart)||void 0===n?void 0:n.series,c=(null===u||void 0===u?void 0:u.pointsSize)||s.DEFAULT_POINT_SIZE;function d(i,n,u,d){const{scale:h,_focus:f,color:p,getFocusedColor:g,type:m}=i.series[n];let _=u;const v="dots"===m?a?o:c:o;for(;_<=d;){const o=i.data[n][_];null!==o&&(0,t.renderCircle)(i,i.data[0][_],o,v,l,(f||null===f?p:g(e,n))||p,r,h||s.DEFAULT_Y_SCALE),_++}}const h=(e,t)=>{0!==e&&null!==e&&("dots"===t.type||i.markers.show)&&(t.points=t.points||{},t.points.show=d)};return{opts:(e,t)=>{(i.markers.show||t.series.some((e=>"dots"===e.type)))&&t.series.forEach(((e,t)=>h(t,e)))},hooks:{addSeries:(e,t)=>{const i=e.series[t];h(t,i)},setSeries:(e,t,i)=>{h(t,i)}}}}},15648:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0});const s=i(46976),n=i(48643),o=i(50497),l=i(80152),r={[n.DrawOrderKey.Series]:0,[n.DrawOrderKey.Axes]:1,plotLines:2},a={"012":"draw",102:"draw",201:"drawClear",210:"drawClear",120:"drawAxes","021":"drawSeries"};t.default=function(e){let t=new Map;return function(i){var n;const u=null===(n=i.config.chart.appearance)||void 0===n?void 0:n.drawOrder,c=(u?u.map((e=>r[e])):[0,1,2]).join(""),d=a[c]||"drawClear";function h(e){var i;if(e.id)return e.id;return(null===(i=Array.from(t.entries()).find((([t,i])=>(0,o.deepIsEqual)(i,e))))||void 0===i?void 0:i[0])||(0,o.genId)()}function f(n){const{ctx:o}=n,{height:r,top:a,width:u,left:c}=n.bbox,d=n.data[0];for(const h of t.values()){if(!h.scale)continue;if(e.render){e.render(n,h);continue}o.save(),o.fillStyle=i.utils.colors.parse(h.color);const{scale:t,value:f}=h,p=Array.isArray(f),[g,m]=p?(0,l.calculateFromTo)(f,t,d,n):[n.valToPos(f,t,!0),0];if(p){const e=h.accent;t===s.DEFAULT_X_SCALE?(o.fillRect(g,a,m-g,r),e&&(o.fillStyle=e.color,o.fillRect(g,a-e.space,m-g,e.space))):(o.fillRect(c,g,u,m-g),e&&(o.fillStyle=e.color,o.fillRect(u+c,g,e.space,m-g)))}else{const e=h;if(o.beginPath(),t===s.DEFAULT_X_SCALE){const e=n.data[0][n.data[0].length-1];if(g-n.valToPos(e,t,!0)>0)continue;o.moveTo(g,a),o.lineTo(g,r+a)}else o.moveTo(c,g),o.lineTo(u+c,g);o.lineWidth=e.width||s.DEFAULT_CANVAS_PIXEL_RATIO,o.strokeStyle=e.color||"#000",e.dash&&o.setLineDash(e.dash),o.stroke()}o.restore()}}const p="drawSeries"===d?(e,t)=>{t===e.series.length-1&&f(e)}:f;function g(e){e?t.forEach(((i,s)=>{i.scale===e&&t.delete(s)})):t.clear()}return{get:function(){return Array.from(t.values())},clear:g,remove:function(e){for(const i of e){const e=h(i);t.delete(e)}},add:function(e){for(const i of e){const e=h(i);t.set(e,i)}},update:function(e,i){if(!e||0===e.length)return void g(i);const s=new Set;for(const n of e){const e=h(n);t.set(e,n),s.add(e)}for(const[n,o]of t.entries())i&&o.scale!==i||s.has(n)||t.delete(n)},uplot:{opts:()=>{const e=i.config;t=new Map;for(const i in e.axes)if(e.axes.hasOwnProperty(i)){const s=e.axes[i];if(s.plotLines)for(const e of s.plotLines)t.set(e.id||(0,o.genId)(),{...e,scale:i})}},hooks:{[d]:p}}}}}},4553:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.calculateFromTo=t.getPosition=void 0;const s=i(46976);function n(e,t,i,n){return e>0&&t===s.DEFAULT_X_SCALE?i:e>0&&t!==s.DEFAULT_X_SCALE||e<=0&&t===s.DEFAULT_X_SCALE?0:n}t.getPosition=n,t.calculateFromTo=function(e,t,i,o){return e.map((e=>{var l,r;if(Math.abs(e)!==1/0){if(t===s.DEFAULT_X_SCALE)return Math.min(Math.max(e,i[0]),i[i.length-1]);{const i=o.scales[t];return Math.min(Math.max(e,null!==(l=i.min)&&void 0!==l?l:e),null!==(r=i.max)&&void 0!==r?r:e)}}const a=n(e,t,o.width,o.height);return o.posToVal(a,t)})).map((e=>o.valToPos(e,t,!0)))}},80152:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.calculateFromTo=void 0;var s=i(4553);Object.defineProperty(t,"calculateFromTo",{enumerable:!0,get:function(){return s.calculateFromTo}})},48840:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0});const s=i(50497),n={size:["height","width"],clientSize:["clientHeight","clientWidth"],offsetSize:["offsetHeight","offsetWidth"],maxSize:["maxHeight","maxWidth"],before:["top","left"],marginBefore:["marginTop","marginLeft"],after:["bottom","right"],marginAfter:["marginBottom","marginRight"],scrollOffset:["pageYOffset","pageXOffset"],offset:["offsetY","offsetY"],offsetOpt:["yOffset","xOffset"],bodyScroll:["scrollHeight","scrollWidth"],inner:["innerHeight","innerWidth"]};function o(e){return{top:e.top,bottom:e.bottom,left:e.left,right:e.right}}t.default=function(e,t,i="bottom",l={}){let r;r=t instanceof Element||t instanceof Range?o(e.getBoundingClientRect()):t;const a=Object.assign({top:r.bottom||0,bottom:r.top||0,left:r.right||0,right:r.left||0},r),u={top:0,left:0,bottom:window.innerHeight,right:window.innerWidth};l.bound&&((l.bound instanceof Element||l.bound instanceof Range)&&(l.bound=o(l.bound.getBoundingClientRect())),Object.assign(u,l.bound));const c=getComputedStyle(e),{primary:d,secondary:h}=Object.entries(n).reduce(((e,[t,s])=>({primary:{...e.primary,[t]:s["top"===i||"bottom"===i?0:1]},secondary:{...e.secondary,[t]:s["top"===i||"bottom"===i?1:0]}})),{primary:{},secondary:{}});e.style.position="absolute",e.style.maxWidth="",e.style.maxHeight="";const f=l[d.offsetOpt]||0,p=parseInt(c[h.marginBefore],10),g=p+parseInt(c[h.marginAfter],10),m=u[h.after]-u[h.before]-g,_=parseInt(c[h.maxSize],10);(!_||m<_)&&(e.style[h.maxSize]=(0,s.px)(m));const v=parseInt(c[d.marginBefore],10)+parseInt(c[d.marginAfter],10),y=a[d.before]-u[d.before]-v,b=u[d.after]-a[d.after]-v-f;(i===d.before&&e[d.offsetSize]>y||i===d.after&&e[d.offsetSize]>b)&&(i=y>b?d.before:d.after);const w=i===d.before?y:b,E=parseInt(c[d.maxSize],10);(!E||wMath.max(u[d.before],Math.min(t,u[d.after]-e[d.offsetSize]-v));i===d.before?(e.style[d.before]=x+A(a[d.before]-e[d.offsetSize]-v)-f+"px",e.style[d.after]="auto"):(e.style[d.before]=(0,s.px)(x+A(a[d.after])+f),e.style[d.after]="auto");const T=document.body[h.bodyScroll]-window[h.inner],O=Math.max(Math.min(window[h.scrollOffset],T),0);var L;return e.style[h.before]=(0,s.px)(O+(L=a[h.before]-p,Math.max(u[h.before],Math.min(L,u[h.after]-e[h.offsetSize]-g)))),e.style[h.after]="auto",e.dataset.side=i,{side:i,anchorRect:a,boundRect:u}}},74947:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.renderTooltip=void 0;const s=i(48130);t.renderTooltip=function(e){if(0===e.scales.length)return e.yagr.utils.i18n("nodata");const[t,i]=e.options.title?"string"===typeof e.options.title?[e.options.title,!1]:["",!0]:["",!1];return`${t?`
${t}
`:""}${e.scales.map((t=>{const n=(0,s.getOptionValue)(e.options.title,t.scale),o=e.scales.length>1?e.options.scales?`${(0,s.getOptionValue)(e.options.scales,t.scale)||""}`:`${e.yagr.utils.i18n("scale")}: ${t.scale}`:"";return`\n
\n ${i&&n?`
${n}
`:""}\n ${o?`
${o}
`:""}\n
${function(e,t,i){const n=e.slice(0,(0,s.getOptionValue)(t.maxLines,i));return n.map((({value:i,name:n="unnamed",color:o,active:l,transformed:r,seriesIdx:a},u)=>{const c=`\n${i}\n ${"number"===typeof r?`${r.toFixed(2)}`:""}\n`;return`\n
\n ${t.showIndicies?`${e.length-u}`:""}\n ${(0,s.escapeHTML)(n)}  ${c}\n
`})).join("")+(e.length>n.length?`
+${e.length-n.length}
`:"")}(t.rows,e.options,t.scale)}
\n ${(0,s.getOptionValue)(e.options.sum,t.scale)?`\n
\n ${e.yagr.utils.i18n("sum")}: ${t.sum}\n
\n `:""}\n
`})).join("")}`}},25700:function(e,t,i){var s=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0});const n=s(i(48840)),o=i(46976),l=i(50497),r=i(74947),a=i(48130),u=(e,t,i,s,n)=>{var o,r,a;const u=Array.isArray(i.$c)?i.$c:t;let c=u[s];if(n&&c===n.value){const e=null!==(o=n.snapToValues)&&void 0!==o?o:"closest";c=u[(0,l.findDataIdx)(u,i,s,e,n.value)]}else if(null===c){const t=null!==(r=e.snapToValues)&&void 0!==r?r:"closest",n=null!==(a=i.snapToValues)&&void 0!==a?a:t;c=u[(0,l.findDataIdx)(u,i,s,n,null)]}return c},c={maxLines:o.TOOLTIP_DEFAULT_MAX_LINES,highlight:!0,sum:!1,render:r.renderTooltip,pinable:!0,strategy:"pin",sort:void 0,showIndicies:!1,hideNoData:!1,className:"yagr-tooltip_default",xOffset:o.TOOLTIP_X_OFFSET,yOffset:o.TOOLTIP_Y_OFFSET,virtual:!1,showEmpty:!1,onUpdate:"reset"};class d{constructor(e,t={}){var i,s;this.handlers={init:[],mount:[],show:[],pin:[],unpin:[],hide:[],render:[],destroy:[],reset:[]},this.placement=n.default,this.renderTooltipCloses=()=>{},this.skipNextMouseUp=!1,this.emit=(e,t)=>{this.handlers[e].forEach((i=>{i(this.tOverlay,{state:this.state,actions:{pin:this.pin,show:this.show,hide:this.hide,dispose:this.dispose,reset:this.reset},data:t,yagr:this.yagr,event:e})}))},this.reset=()=>{var e;"none"!==this.opts.onUpdate?(this.state.visible&&this.hide(),this.state.pinned&&this.pin(!1),this.emit("reset")):null===(e=this.yagr.plugins.cursor)||void 0===e||e.pin(!1)},this.show=()=>{const e=!this.state.visible;this.state.visible=!0,this.tOverlay.style.display="block",e&&this.emit("show")},this.hide=()=>{const e=this.state.visible;this.state.visible=!1,this.tOverlay.style.display="none",this.emit("hide"),e&&this.emit("show")},this.pin=(e,t)=>{var i;this.state.pinned=e;const s=this.state.range||[];if(null===(i=this.yagr.plugins.cursor)||void 0===i||i.pin(e&&(null===s[1]||s.length<2)),this.opts.virtual)return this.emit(e?"pin":"unpin");t&&this.placement(this.tOverlay,{left:t.x+this.bLeft,top:this.bTop+t.y-(this.opts.yOffset||0)},"right",{bound:this.bound,xOffset:this.opts.xOffset,yOffset:this.opts.yOffset});const n=this.tOverlay.querySelector("._tooltip-list");e?(this.state.visible||this.show(),this.tOverlay.classList.add("yagr-tooltip_pinned"),n&&(null===n||void 0===n?void 0:n.clientHeight)&&(n.style.height=(0,l.px)(n.clientHeight)),this.opts.render===r.renderTooltip&&(document.addEventListener("mousemove",this.checkFocus),document.addEventListener("mousedown",this.detectClickOutside))):(this.tOverlay.classList.remove("yagr-tooltip_pinned"),this.opts.render===r.renderTooltip&&(document.removeEventListener("mousemove",this.checkFocus),document.removeEventListener("mousedown",this.detectClickOutside))),this.emit(e?"pin":"unpin")},this.checkFocus=e=>{const t=e.target;let i;t&&this.tOverlay.contains(t)&&t.classList.contains("yagr-tooltip__item")&&(i=t.dataset.series);const s=i?this.yagr.uplot.series[Number(i)]:null;i&&s?(this.state.focusedSeries=i,this.yagr.setFocus(s.id,!0)):this.state.focusedSeries&&(this.state.focusedSeries=null,this.yagr.setFocus(null,!0))},this.render=e=>{const t=this.yagr.uplot;let{left:i,top:s}=e;const{idx:n}=e,{opts:r,state:d}=this;if(r.show&&"function"===typeof r.show&&!1===r.show(this.yagr))return void this.hide();(i<0||s<0)&&!d.pinned&&this.isNotInDrag&&this.hide(),s=(0,l.inBetween)(s,0,t.bbox.top+t.bbox.height),i=(0,l.inBetween)(i,0,t.bbox.left+t.bbox.width);const{data:h}=t;if(null===h||(0,l.isNil)(n)||void 0===s)return;const f=h[0][n],p={},g={},m={};let _=t.series.length-1;for(;_>=1;){const e=t.series[_];if(!e.show){_-=1;continue}const i=e.scale||o.DEFAULT_Y_SCALE;m[i]=m[i]||[],m[i].push(_),_-=1}Object.entries(m).forEach((([e,o])=>{var c;g[e]=g[e]||{rows:[]};const d=g[e],h=Number(t.posToVal(s,e).toFixed(2)),f=(0,a.getOptionValue)(r.value,e);for(const i of o){const s=t.data[i],o=t.series[i];let l=u(this.yagr.config.cursor,s,o,n,this.interpolation),h=l;"string"===typeof l&&(h=l,l=null),(0,a.getOptionValue)(r.sum,e)&&(p[e]=p[e]||0,p[e]+=l||0);const g=s[n],m=o.$c&&o.$c[n]===this.stripValue?l:g;if(null===l&&r.hideNoData||!1===o.showInTooltip)continue;const _=null!==(c=o.precision)&&void 0!==c?c:(0,a.getOptionValue)(r.precision,e),v=o.formatter?o.formatter(h,o):f(h,_),y={id:o.id,name:o.name,dataValue:o.$c[n],originalValue:l,value:v,y:m,displayY:g,color:this.yagr.getSerieLegendColor(o),seriesIdx:i,rowIdx:d.rows.length?d.rows[d.rows.length-1].rowIdx+1:0};o.normalizedData&&(y.transformed=o.normalizedData[n]),o._transformed&&(y.transformed=s[n]),r.omitBy&&r.omitBy(y)||d.rows.push(y)}if((0,a.getOptionValue)(r.highlight,e)&&d.rows.length){const u=(0,a.getOptionValue)(r.tracking,e);let c=0;"area"===u?c=(0,l.findInRange)(d,h,(0,a.getOptionValue)(r.stickToRanges,e)):"sticky"===u?c=(0,l.findSticky)(d,h):"function"===typeof u&&(c=u(d,h,{x:t.posToVal(i,"x"),y:t.posToVal(s,e),idx:n,scale:e,series:this.yagr.series,serieIndicies:o,interpolation:this.interpolation})),null!==c&&(d.rows[c].active=!0)}const m=(0,a.getOptionValue)(r.sort,e);m&&d.rows.sort(m)}));if(!Object.values(g).some((({rows:e})=>e.length>0))&&!r.showEmpty)return void this.hide();this.onMouseEnter();const v=this.over.getBoundingClientRect();this.bLeft=v.left,this.bTop=v.top,this.bWidth=v.width;const y={left:i+this.bLeft,top:this.bTop+s-(r.yOffset||0)};this.renderTooltipCloses=()=>{const e={scales:Object.entries(g).map((([e,t])=>({scale:e,rows:t.rows,sum:p[e]}))),options:r,x:f},t=Object.values(g).some((({rows:e})=>e.filter((({id:e})=>{var t;return null===(t=this.yagr.getSeriesById(e))||void 0===t?void 0:t.show})).length>0));t||r.showEmpty?(r.virtual||(this.tOverlay.innerHTML=r.render({...e,state:d,yagr:this.yagr,defaultRender:c.render}),this.placement(this.tOverlay,y,"right",{bound:this.bound,xOffset:r.xOffset,yOffset:r.yOffset})),this.emit("render",{...e,anchor:y})):this.hide()},d.pinned||this.renderTooltipCloses()},this.initWithUplot=e=>{this.over=e.root.querySelector(".u-over"),this.over.addEventListener("mousedown",this.onMouseDown),this.over.addEventListener("mousemove",this.onMouseMove),this.over.addEventListener("mouseenter",this.onMouseEnter),this.over.addEventListener("mouseleave",this.onMouseLeave),document.addEventListener("mouseup",this.onMouseUp)},this.setSize=()=>{const e=this.over.getBoundingClientRect();this.bLeft=e.left,this.bTop=e.top},this.dispose=()=>{this.over.removeEventListener("mousedown",this.onMouseDown),this.over.removeEventListener("mousemove",this.onMouseMove),this.over.removeEventListener("mouseenter",this.onMouseEnter),this.over.removeEventListener("mouseleave",this.onMouseLeave),document.removeEventListener("mouseup",this.onMouseUp),document.removeEventListener("mousemove",this.checkFocus),document.removeEventListener("mousedown",this.detectClickOutside),this.tOverlay.remove(),this.state.mounted=!1,this.emit("destroy")},this.updateOptions=e=>{Object.assign(this.opts,e),this.tOverlay.className=`yagr-tooltip ${this.opts.className||""}`},this.on=(e,t)=>{this.handlers[e].push(t)},this.off=(e,t)=>{this.handlers[e]=this.handlers[e].filter((e=>e!==t))},this.detectClickOutside=e=>{const t=e.target;if(t instanceof Element){const e=t&&this.tOverlay.contains(t),i=t&&this.over.contains(t);e||i||(this.pin(!1),this.hide())}},this.onMouseDown=e=>{this.state.range=[this.getCursorPosition(),null],this.state.pinned&&(this.pin(!1),this.hide(),this.render({left:e.clientX-this.bLeft,top:e.clientY-this.bTop,idx:this.yagr.uplot.posToIdx(e.clientX-this.bLeft)}),this.skipNextMouseUp=!0)},this.onMouseMove=()=>{var e;(null===(e=this.state.range)||void 0===e?void 0:e.length)&&(this.state.range[1]=this.getCursorPosition())},this.setCursorLeaved=e=>{const t=this.over.getBoundingClientRect(),i=e.clientX,s=this.state.range,n=s[0],o=i-t.left>n.clientX,l=this.yagr.config.timeline;let r;o?(s[1]={clientX:this.bWidth,value:this.yagr.uplot.posToVal(this.bWidth,"x"),idx:l.length-1},r=s[1]):(s[1]=s[0],s[0]={clientX:0,value:this.yagr.uplot.posToVal(0,"x"),idx:0},r=s[0]),this.yagr.uplot.setCursor({left:r.clientX,top:e.clientY-t.top})},this.onMouseUp=e=>{if(null===this.state.range)return;const[t]=this.state.range||[];let i;if(i=e.target===this.over?this.getCursorPosition():this.state.range[1],"none"===this.opts.strategy)return;const s=t&&t.clientX===(null===i||void 0===i?void 0:i.clientX),n=t&&t.clientX!==(null===i||void 0===i?void 0:i.clientX),o=this.opts.strategy;(s&&!this.skipNextMouseUp&&"drag"!==o||n&&("all"===o||"drag"===o))&&(this.pin(!this.state.pinned),this.show(),this.renderTooltipCloses()),this.state.range=null,this.skipNextMouseUp=!1},this.onMouseEnter=()=>{this.show()},this.onMouseLeave=e=>{var t;const i=this.state.pinned;(null===(t=this.state.range)||void 0===t?void 0:t[0])&&this.setCursorLeaved(e),!i&&this.isNotInDrag&&this.hide()},this.defaultTooltipValueFormatter=(e,t)=>{const i=this.yagr.config.processing||{};return"string"===typeof e?i.nullValues&&i.nullValues.hasOwnProperty(e)?i.nullValues[e]:"-":"number"===typeof e?e.toFixed("number"===typeof t?t:"number"===typeof this.opts.precision?this.opts.precision:2):"-"},this.getCursorPosition=()=>{const e=this.yagr.uplot.cursor.left;return void 0===e?null:{clientX:e,value:this.yagr.uplot.posToVal(e,"x"),idx:this.yagr.uplot.posToIdx(e)}},this.yagr=e,this.over=null===(i=null===e||void 0===e?void 0:e.uplot)||void 0===i?void 0:i.over,this.opts={...c,strategy:t.pinable?"pin":c.strategy,tracking:"area"===(null===(s=e.config.chart.series)||void 0===s?void 0:s.type)?"area":"sticky",value:this.defaultTooltipValueFormatter,...t},this.bound=this.opts.boundClassName&&document.querySelector(this.opts.boundClassName)||document.body,this.renderNode=this.opts.renderClassName&&document.querySelector(this.opts.renderClassName)||document.body,this.tOverlay=document.createElement("div"),this.tOverlay.id=`${e.id}_tooltip`,this.tOverlay.className=`yagr-tooltip ${this.opts.className||""}`,this.tOverlay.style.display="none",this.state={mounted:!1,pinned:!1,visible:!1,range:null,focusedSeries:null},this.bLeft=0,this.bTop=0,this.bWidth=0,this.opts.virtual?this.placement=()=>{}:(this.renderNode.appendChild(this.tOverlay),this.state.mounted=!0,this.emit("mount"))}get interpolation(){var e;return null===(e=this.yagr.config.processing)||void 0===e?void 0:e.interpolation}get stripValue(){return this.interpolation?this.interpolation.value:void 0}get isNotInDrag(){var e;return"none"===this.opts.strategy||"pin"===this.opts.strategy||!(null===(e=this.state.range)||void 0===e?void 0:e[1])}}t.default=function(e,t={}){const i=new d(e,t),s=()=>({hooks:{destroy:()=>{i.dispose()},init:e=>{i.initWithUplot(e)},setSize:()=>{i.setSize()},setCursor:e=>{i.render(e.cursor)}}}),n=s();return{state:i.state,pin:i.pin,show:i.show,hide:i.hide,uplot:n,display:i.render,updateOptions:i.updateOptions,on:i.on,off:i.off,tooltip:i,dispose:i.dispose,reInit:function(e){const t=s();i.reset(),e.hooks.init.push(t.hooks.init),e.hooks.destroy.push(t.hooks.destroy),e.hooks.setSize.push(t.hooks.setSize),e.hooks.setCursor.push(t.hooks.setCursor)},reset:i.reset}}},98190:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0})},48130:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.escapeHTML=t.getOptionValue=void 0,t.getOptionValue=function(e,t){return"object"===typeof e?e[t]:e},t.escapeHTML=function(e){const t=document.createElement("span");return t.innerText=e,t.innerHTML}},89353:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0})},24793:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t},l=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.configureAxes=t.updateAxis=t.getRedrawOptionsForAxesUpdate=t.getTimeFormatter=t.getDefaultNumberFormatter=t.getAxisPositioning=void 0;const r=l(i(16381)),a=o(i(46976)),u=i(50497),c=i(48643),d={right:c.Axis.Side.Right,top:c.Axis.Side.Top,bottom:c.Axis.Side.Bottom,left:c.Axis.Side.Left},h={left:c.Axis.Align.Right,right:c.Axis.Align.Left,top:void 0,bottom:void 0};t.getAxisPositioning=(e,t)=>({side:e?d[e]:c.Axis.Side.Left,align:t||(e?h[e]:void 0)});t.getDefaultNumberFormatter=(e,t="")=>i=>{if((0,u.isNil)(i))return t;if(0===i)return"0";const s=Math.abs(i),n="auto"===e?2:e,[o,l]=(0,u.getUnitSuffix)(s),r=i/o;return("auto"===e?String(r).replace(/\.(\d{5,})/,(e=>e.slice(0,6))):(0,u.toFixed)(r,n))+l};const f=e=>{const i=e.precision,s=(0,t.getDefaultNumberFormatter)("number"===typeof i?i:i||"auto","");return function(e,t){return t.map(s)}},p=r.default.fmtDate("{DD}.{MM}.{YYYY}"),g=r.default.fmtDate("{HH}:{mm}:{ss}"),m=r.default.fmtDate("{mm}:{ss}"),_=r.default.fmtDate("{mm}:{ss}.{fff}"),v=r.default.fmtDate("{YYYY}");function y(e,t){let i=p;const s=Math.ceil(e/t);return s<=a.SECOND?i=_:s<=a.MINUTE?i=m:s<=a.DAY?i=g:s>=a.YEAR&&(i=v),e=>i(new Date(e))}function b(e,i){var s,n;const o=i.utils.theme,l=i.config,r={splits:e.splitsCount?(c=e.splitsCount,(e,t,i,s)=>{if(c<=2)return[i,s];const n=Math.abs(s-i)/(c-1);let o=n;const l=[];for(;i+oo.AXIS_STROKE),ticks:e.ticks?{...o.Y_AXIS_TICKS,...e.ticks}:o.Y_AXIS_TICKS,grid:l.grid||e.grid||o.GRID};var c;return e.scale===a.DEFAULT_X_SCALE?Object.assign(r,{getFormatter:y,gap:null!==(s=e.gap)&&void 0!==s?s:a.X_AXIS_TICK_GAP,size:(0,u.asFn)(e.size)||(()=>a.X_AXIS_SIZE),values:e.values||(0,t.getTimeFormatter)(l),ticks:e.ticks?{...o.X_AXIS_TICKS,...e.ticks}:o.X_AXIS_TICKS,scale:a.DEFAULT_X_SCALE,space:e.space||(()=>a.X_AXIS_SPACE),incrs:e.incrs||(()=>a.X_AXIS_INCRS.map((e=>e*(l.chart.timeMultiplier||a.TIME_MULTIPLIER)))),side:2,stroke:e.stroke||(()=>o.AXIS_STROKE)}):(Object.assign(r,{gap:null!==(n=e.gap)&&void 0!==n?n:a.Y_AXIS_TICK_GAP,size:(0,u.asFn)(e.size)||a.Y_AXIS_SIZE,values:e.values||f(e),scale:e.scale||a.DEFAULT_Y_SCALE,getFormatter:()=>(0,t.getDefaultNumberFormatter)("number"===typeof e.precision?e.precision:e.precision||"auto",""),...(0,t.getAxisPositioning)(e.side||"left",e.align)}),e.space&&(r.space=e.space),r)}function w(e){let t,i;return[e=e.replace(/(\d+)px/,((e,s)=>(0,u.px)(t=Math.round((i=Number(s))*window.devicePixelRatio)))),t,i]}t.getTimeFormatter=e=>{const t=e.chart.timeMultiplier||a.TIME_MULTIPLIER;return(e,i)=>{const s=y((i[i.length-1]-i[0])/t,i.length);return i.map((e=>s(e/t)))}},t.getRedrawOptionsForAxesUpdate=function(e){const t=[!1,!0];return Object.values(e).forEach((e=>{["align","side","size","label","labelFont","labelGap","labelSize"].some((t=>void 0!==e[t]))&&(t[1]=!0)})),t},t.updateAxis=function(e,t,i){var s,n,o;const l=b({...i,font:t.font},e);l.ticks={...t.ticks,...l.ticks},l.grid={...t.grid,...l.grid},l.border={...t.border,...l.border},l.splits=l.splits||t.splits,i.font&&i.font!==(null===(s=t.font)||void 0===s?void 0:s[0])&&(l.font=w(i.font)),i.labelFont&&i.labelFont!==(null===(n=t.labelFont)||void 0===n?void 0:n[0])&&(l.labelFont=w(i.labelFont)),Object.assign(t,l),null===(o=e.plugins.plotLines)||void 0===o||o.update(i.plotLines,i.scale)},t.configureAxes=function(e,t){const i=[];Object.entries(t.axes).forEach((([t,s])=>{i.push(b({...s,scale:t},e))}));const s=a.DEFAULT_X_SCALE,n=a.DEFAULT_Y_SCALE;return t.axes[s]||i.push(b({scale:s},e)),i.find((({scale:e})=>e!==s))||i.push(b({scale:n},e)),i}},27658:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t};Object.defineProperty(t,"__esModule",{value:!0}),t.getPaddingByAxes=void 0;const l=o(i(46976));t.getPaddingByAxes=function(e){let t=!1,i=!1;return e.axes?e.axes.forEach((e=>{e.scale!==l.DEFAULT_X_SCALE&&(void 0!==e.side&&3!==e.side||(t=!0),1===e.side&&(i=!0))})):t=!0,t&&!i?l.PADDING_LEFT:i&&!t?l.PADDING_RIGHT:l.PADDING_BOTH}},20500:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.getSerieFocusColors=t.getFocusedColor=void 0;const i=[0,0,0,.6];class s{static parseRgba(e){const t=e.match(/rgba?\s*\(\s*(\d+)\s*,\s*(\d+)\s*,\s*(\d+)\s*,?\s*(\d+\.?\d*)?\s*\)/);return t?[t[1],t[2],t[3],t[4]||1].map(Number):null}parse(e="000"){const t=e.startsWith("var(--");let i,s=e,n=!0;const o=this.context,l=o.style.color;return t||e.startsWith("--")?(n=!1,i=t?e.slice(4,-1):e):e.startsWith("#")||e.startsWith("rgb")||(o.style.color=e,i="color",n=!1),s=n?s:getComputedStyle(o).getPropertyValue(i),o.style.color=l,s}setContext(e){this.context=e}rgba(e){return`rgba(${e[0]}, ${e[1]}, ${e[2]}, ${e[3]})`}toRgba(e,t){return s.parseRgba(this.parse(e))||t}shade([e,t,i,s],n){const o=n<0,l=o?0:255*n,r=o?1+n:1-n;return"rgba("+Math.round(e*r+l)+","+Math.round(t*r+l)+","+Math.round(i*r+l)+","+s+")"}}t.default=s;t.getFocusedColor=(e,t)=>{const n=e.utils.theme.SHIFT,o=e.uplot.series[t],l=s.parseRgba(o.color)||i;return e.utils.colors.shade(l,n)};t.getSerieFocusColors=(e,t)=>(i,s)=>{const n=i.series[s];return!1===n._focus?n.getFocusedColor(e,s):n[t]}},50497:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.inBetween=t.isNil=t.asPlain=t.asFn=t.deepIsEqual=t.get=t.html=t.px=t.debounce=t.exec=t.preprocess=t.genId=t.findDataIdx=t.toFixed=t.getUnitSuffix=t.findSticky=t.getSumByIdx=t.findInRange=void 0;t.findInRange=(e,t,i=!0)=>{const s=t>=0;let n=-1/0,o=null,l=1/0,r=null;const a=[];let u=null;for(let c=e.rows.length-1;c>=0;c--){const i=e.rows[c],{displayY:d,rowIdx:h}=i;let f;null!==d&&(d>n&&(n=d,o=i.rowIdx),d=0)?null:s?t>d?null:d-t:t=n?o:t<=l?r:null:u};t.getSumByIdx=(e,t,i)=>{let s=0,n=0;for(;n{let i,s,n=0;for(;!s&&nl&&(s=l,i=n)}return i};t.getUnitSuffix=e=>e>=1e18?[1e18,"E"]:e>=1e15?[1e15,"P"]:e>=1e12?[1e12,"T"]:e>=1e9?[1e9,"G"]:e>=1e6?[1e6,"M"]:e>=1e3?[1e3,"K"]:[1,""],t.toFixed=function(e,t){if(0===t)return parseInt(e);if(Number.isInteger(e))return e+"."+"0".repeat(t);const[i,s]=e.toString().split(".");return s.length>=t?`${i}.${s.slice(0,t)}`:`${i}.${s}${"0".repeat(t-s.length)}`},t.findDataIdx=function(e,t,i,s="closest",n=null){var o;let l=i,r=i;const a=null!==(o=t.snapToValues)&&void 0!==o?o:s;if(!1===a)return i;if("left"===a||"closest"===a)for(let u=i-1;u>=0;u--)if(e[u]!==n){l=u;break}if("right"===a||"closest"===a)for(let u=i+1;ui-l?l:r};const i=(e,t,i,s,n,o,l,r="linear")=>{let a=null;const u=e[o];switch(r){case"linear":if(null===t||null===i)return null;a=t+(u-s)*(i-t)/(n-s),(isNaN(a)||Math.abs(a)===1/0)&&(a=null);break;case"previous":a=t;break;case"next":a=i;break;case"left":a=l[l.length-1]===e.length-1||null===i?null:t;break;case"right":a=0===l[0]?null:i;break;case"closest":a=Math.abs(s-e[o])Date.now().toString(36)+Math.random().toString(36).substring(2);t.preprocess=(e,t,s)=>{const n=[],o=s.nullValues||{},l=s.interpolation;for(let r=0;r"function"===typeof e?e(...t):e,t.debounce=function(e,t=300){let i;return(...s)=>{clearTimeout(i),i=setTimeout((()=>e(...s)),t)}};t.px=e=>e+"px";function s(e){return null===e||void 0===e}t.html=(e,t={},i)=>{const s=document.createElement(e);return Object.keys(t).forEach((e=>{const i=t[e];s.setAttribute(e,"object"===typeof i?Object.entries(i).map((([e,t])=>`${e}:${t}`)).join(";"):i)})),i&&("string"===typeof i?s.innerHTML=i:s.appendChild(i)),s},t.get=function(e,t){return t.split(".").reduce(((e,t)=>{var i,s;return null!==(s=null===(i=Object.getOwnPropertyDescriptor(e,t))||void 0===i?void 0:i.value)&&void 0!==s?s:{}}),e)},t.deepIsEqual=function e(t,i){if(typeof t!==typeof i)return!1;if("function"!==typeof t&&"function"!==typeof i||(t=t.toString(),i=i.toString()),"object"!==typeof t||s(t)||s(i))return t===i;const n=t,o=i,l=Object.keys(n),r=Object.keys(o);if(l.length!==r.length)return!1;for(const s of l){if(!o.hasOwnProperty(s))return!1;if(!e(n[s],o[s]))return!1}return!0},t.asFn=function(e){return"function"===typeof e||"undefined"===typeof e?e:()=>e},t.asPlain=function(e){return"function"===typeof e?e():e},t.isNil=s,t.inBetween=function(e,t,i){return e>=t&&e<=i?e:e{Object.defineProperty(t,"__esModule",{value:!0}),t.preventMouseEvents=void 0;t.preventMouseEvents=e=>e.preventDefault()},87102:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.applyMixins=void 0,t.applyMixins=function(e,t){const i=[];t.forEach((t=>{Object.getOwnPropertyNames(t.prototype).forEach((i=>{Object.defineProperty(e.prototype,i,Object.getOwnPropertyDescriptor(t.prototype,i)||Object.create(null))})),t.prototype.initMixin&&i.push(t.prototype.initMixin)})),e.prototype.initMixins=function(){i.forEach((e=>e.call(this)))}}},88274:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t},l=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.pathsRenderer=void 0;const r=l(i(16381)),a=o(i(46976));t.pathsRenderer=function(e,t,i,s){const n=e.series[t],{type:o,interpolation:l}=n;let u;switch(o){case"column":u=r.default.paths.bars&&r.default.paths.bars({size:[a.BARS_DRAW_FACTOR,a.BARS_DRAW_MAX],...e.series[t].renderOptions||{}});break;case"dots":u=()=>null;break;default:switch(l){case"smooth":u=r.default.paths.spline&&r.default.paths.spline();break;case"left":u=r.default.paths.stepped&&r.default.paths.stepped({align:1});break;case"right":u=r.default.paths.stepped&&r.default.paths.stepped({align:-1});break;default:u=r.default.paths.linear&&r.default.paths.linear()}}return u?u(e,t,i,s):null}},81891:(e,t,i)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.configureScales=t.niceScale=t.offsetScale=t.getScaleRange=void 0;const s=i(46976),n=i(48643);function o(e,t,i){const n=e>=0&&i.stacking,o=t<=0&&i.stacking;return{min:n?0:Math.round(e-Math.abs(e)*(i.offset||s.DEFAULT_Y_AXIS_OFFSET)),max:o?0:Math.round(t+Math.abs(t)*(i.offset||s.DEFAULT_Y_AXIS_OFFSET))}}function l(e,t,i){const n=e>=0&&i.stacking,o=t<=0&&i.stacking?0:"number"===typeof i.max?i.max:t,l=n?0:"number"===typeof i.min?i.min:e;if(l===o)return l>=0?{min:l,max:l+2}:{min:l-1,max:l+1};const a=r(o-l,!1),u=r(a/(s.DEFAULT_MAX_TICKS-1),!0);let c=Math.ceil(o/u)*u;c=isNaN(c)?100:c;let d=(n?Math.min(0,l):Math.floor(l/u)*u)||0;return d===c&&(d-=1,c+=1),{min:d,max:c}}function r(e,t){const i=Math.floor(Math.log10(e)),s=e/10**i;return(t?s<1.5?1:s<3?2:s<7?5:10:s<=1?1:s<=2?2:s<=5?5:10)*10**i}t.getScaleRange=(e,t)=>{const i=e.range;if("function"===typeof i)return(e,s,n)=>i(e,s,n,t);if(e.normalize)return[0,e.normalizeBase||100];if("auto"===e.range)return;let n;switch(e.range){case void 0:case"nice":n=l;break;case"offset":n=o;break;default:throw new Error(`Unknown scale range type ${e.range}`)}return(i,o,l)=>{let{min:a,max:u}=n(o,l,e,t);const c=e.minRange||s.DEFAULT_SCALE_MIN_RANGE;if(Math.abs(u-a)=0?u+=c:(u+=c/2,a-=c/2)),a="number"===typeof e.min?e.min:a,u="number"===typeof e.max?e.max:u,"logarithmic"===e.type){const t="number"===typeof e.min;a<=0?a=s.DEFAULT_LOGARITHMIC_MIN_SCALE_VALUE:t||(a=Math.min(a,s.DEFAULT_LOGARITHMIC_MIN_SCALE_VALUE))}return(a>=u||u<=a)&&("number"===typeof e.max?a=u-(r(u-.1*u,!1)||1):u=a+(r(a+.1*a,!1)||1)),[a,u]}},t.offsetScale=o,t.niceScale=l,t.configureScales=function(e,i,o){const l=o.scales?{...o.scales}:{};return Object.keys(o.scales).length||(l.y={}),Object.entries(l).forEach((([l,r])=>{i[l]=i[l]||{};const a=i[l];if(l===s.DEFAULT_X_SCALE)return;const u="number"===typeof r.min?r.min:null,c="number"===typeof r.max?r.max:null;if(null!==c&&null!==u){if(c<=u)throw new Error("Invalid scale config. .max should be > .min");a.range=[u,c]}const d="logarithmic"===r.type;if(d)return a.distr=n.Scale.Distr.Logarithmic,void(a.range=(0,t.getScaleRange)(r,o));e.isEmpty?a.range=[null===u?d?1:0:u,null===c?100:c]:a.range=(0,t.getScaleRange)(r,o)})),i.x||(i.x={time:!0}),i}},28265:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t};Object.defineProperty(t,"__esModule",{value:!0}),t.overrideSeriesInUpdate=t.configureSeries=void 0;const l=o(i(46976)),r=i(50497),a=i(20500),u=i(67903),c=i(88274);function d(e,t,i,s){if(void 0!==e[i])return e[i];const n=t.config.chart.series;return n&&i in n?n[i]:s}t.configureSeries=function(e,t,i){var s,n;const o=d(t,e,"type","line"),h={...t,type:o,show:null===(s=t.show)||void 0===s||s,name:t.name||`${e.utils.i18n("series")} ${i+1}`,color:t.color?e.utils.colors.parse(t.color):e.utils.theme.DEFAULT_LINE_COLOR,id:(void 0===t.id?t.name:String(t.id))||(0,r.genId)(),$c:t.data,scale:t.scale||l.DEFAULT_Y_SCALE,count:0,sum:0,avg:0,getFocusedColor:a.getFocusedColor};h.points=h.points||{};const f=(0,a.getSerieFocusColors)(e,"color");return"area"===h.type&&(h.lineColor=e.utils.colors.parse(d(t,e,"lineColor",l.SERIE_AREA_BORDER_COLOR)),h.lineWidth=d(t,e,"lineWidth",l.SERIE_AREA_BORDER_WIDTH),h.fill=f,h.stroke=(0,a.getSerieFocusColors)(e,"lineColor"),h.width=h.lineWidth,h.points.show=u.drawMarkersIfRequired,h.interpolation=d(t,e,"interpolation","linear"),h.spanGaps=d(t,e,"spanGaps",!1)),"line"===h.type&&(h.width=d(t,e,"width",l.SERIE_LINE_WIDTH),h.width=h.width||l.SERIE_LINE_WIDTH,h.stroke=f,h.points.show=u.drawMarkersIfRequired,h.interpolation=d(t,e,"interpolation","linear"),h.spanGaps=d(t,e,"spanGaps",!1)),"column"===h.type&&(h.stroke=f,h.fill=f,h.points.show=!1,h.width=null!==(n=h.width)&&void 0!==n?n:0,h.renderOptions=d(h,e,"renderOptions")),"dots"===h.type&&(h.stroke=()=>h.color,h.fill=f,h.width=2,h.pointsSize=d(h,e,"pointsSize",l.DEFAULT_POINT_SIZE)),h.paths=c.pathsRenderer,h};t.overrideSeriesInUpdate=(e,t)=>{var i,s,n,o,l,r,a,u,c,d,h,f;e.$c=null!==(i=t.$c)&&void 0!==i?i:e.$c,e.show=null!==(s=t.show)&&void 0!==s?s:e.show,e.data=null!==(n=t.data)&&void 0!==n?n:e.data,e.width=null!==(o=t.width)&&void 0!==o?o:e.width,e.pointsSize=null!==(l=t.pointsSize)&&void 0!==l?l:e.pointsSize,e.color=null!==(r=t.color)&&void 0!==r?r:e.color,e.lineColor=null!==(a=t.lineColor)&&void 0!==a?a:e.lineColor,e.lineWidth=null!==(u=t.lineWidth)&&void 0!==u?u:e.lineWidth,e.stroke=null!==(c=t.stroke)&&void 0!==c?c:e.stroke,e.getFocusedColor=null!==(d=t.getFocusedColor)&&void 0!==d?d:e.getFocusedColor,e.formatter=null!==(h=t.formatter)&&void 0!==h?h:e.formatter,e.paths=null!==(f=t.paths)&&void 0!==f?f:e.paths}},48643:(e,t)=>{Object.defineProperty(t,"__esModule",{value:!0}),t.Axis=t.Scale=t.DrawOrderKey=void 0,t.DrawOrderKey={Series:"series",Axes:"axes"},t.Scale={Distr:{Linear:1,Ordinal:2,Logarithmic:3,ArcSinh:4,Custom:5}},t.Axis={Side:{Top:0,Right:1,Bottom:2,Left:3},Align:{Right:0,Left:1}}},68724:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__exportStar||function(e,t){for(var i in e)"default"===i||Object.prototype.hasOwnProperty.call(t,i)||s(t,e,i)},l=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t},r=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.defaults=void 0,o(i(89353),t),o(i(98190),t);const a=l(i(46976));t.defaults=a;const u=r(i(37100));"undefined"!==typeof window&&Object.assign(window,{Yagr:u.default}),t.default=u.default},23936:function(e,t,i){var s=this&&this.__createBinding||(Object.create?function(e,t,i,s){void 0===s&&(s=i);var n=Object.getOwnPropertyDescriptor(t,i);n&&!("get"in n?!t.__esModule:n.writable||n.configurable)||(n={enumerable:!0,get:function(){return t[i]}}),Object.defineProperty(e,s,n)}:function(e,t,i,s){void 0===s&&(s=i),e[s]=t[i]}),n=this&&this.__setModuleDefault||(Object.create?function(e,t){Object.defineProperty(e,"default",{enumerable:!0,value:t})}:function(e,t){e.default=t}),o=this&&this.__importStar||function(e){if(e&&e.__esModule)return e;var t={};if(null!=e)for(var i in e)"default"!==i&&Object.prototype.hasOwnProperty.call(e,i)&&s(t,e,i);return n(t,e),t},l=this&&this.__importDefault||function(e){return e&&e.__esModule?e:{default:e}};Object.defineProperty(t,"__esModule",{value:!0}),t.useTooltipState=void 0;const r=o(i(59284)),a=l(i(37100));t.default=r.forwardRef((function({id:e,config:t,className:i="",debug:s,onChartLoad:n,onSelect:o,update:l="dynamic"},u){const c=r.useRef(null),d=r.useRef();r.useImperativeHandle(u,(()=>({yagr:()=>d.current,domElement:()=>c.current})));const h=r.useCallback((()=>{if(c.current){t.hooks=t.hooks||{};const e=t.hooks;if(n){const t=e.load||[];t.push((({chart:e,meta:t})=>{n(e,t)})),e.load=t}if(o){const t=e.onSelect||[];t.push((({from:e,to:t})=>o(e,t))),e.onSelect=t}d.current=new a.default(c.current,t)}}),[]);r.useEffect((()=>{var e;t&&(null===(e=d.current)||void 0===e||e.setConfig(t,"hard"===l))}),[t]),r.useEffect((()=>(h(),()=>{var e;null===(e=d.current)||void 0===e||e.dispose(),d.current=void 0})),[]);const f=r.useCallback((e=>{if(d.current&&(e.ctrlKey||e.metaKey)&&e.shiftKey){const e=d.current.toDataUrl().replace("image/png","image/octet-stream"),t=document.createElement("a");t.href=e,t.download=((null===s||void 0===s?void 0:s.filename)||d.current.id)+".png",t.click()}}),[e,d]);return r.createElement("div",{id:e,onClick:f,className:`yagr ${i}`,ref:c})}));t.useTooltipState=(e,t)=>{r.useEffect((()=>{var i;if(!e.current||!t.current)return;const s=t.current,n=e.current.yagr();n&&(null===(i=null===n||void 0===n?void 0:n.plugins)||void 0===i?void 0:i.tooltip)&&(n.plugins.tooltip.on("render",((e,t)=>{s.onChange(t)})),n.plugins.tooltip.on("show",((e,t)=>{s.onChange(t)})),n.plugins.tooltip.on("show",((e,t)=>{s.onChange(t)})))}),[e.current])}},16381:(e,t,i)=>{i.r(t),i.d(t,{default:()=>xs});const s="uplot",n="u-hz",o="u-vt",l="u-title",r="u-wrap",a="u-under",u="u-over",c="u-axis",d="u-off",h="u-select",f="u-cursor-x",p="u-cursor-y",g="u-cursor-pt",m="u-legend",_="u-live",v="u-inline",y="u-series",b="u-marker",w="u-label",E="u-value",S="width",x="height",A="top",T="bottom",O="left",L="right",I="#000",D=I+"0",M="mousemove",k="mousedown",C="mouseup",R="mouseenter",F="mouseleave",P="dblclick",U="change",N="dppxchange",$="--",j="undefined"!=typeof window,X=j?document:null,z=j?window:null,H=j?navigator:null;let Y,B;function V(e,t){if(null!=t){let i=e.classList;!i.contains(t)&&i.add(t)}}function W(e,t){let i=e.classList;i.contains(t)&&i.remove(t)}function G(e,t,i){e.style[t]=i+"px"}function K(e,t,i,s){let n=X.createElement(e);return null!=t&&V(n,t),null!=i&&i.insertBefore(n,s),n}function q(e,t){return K("div",e,t)}const Z=new WeakMap;function J(e,t,i,s,n){let o="translate("+t+"px,"+i+"px)";o!=Z.get(e)&&(e.style.transform=o,Z.set(e,o),t<0||i<0||t>s||i>n?V(e,d):W(e,d))}const Q=new WeakMap;function ee(e,t,i){let s=t+i;s!=Q.get(e)&&(Q.set(e,s),e.style.background=t,e.style.borderColor=i)}const te=new WeakMap;function ie(e,t,i,s){let n=t+""+i;n!=te.get(e)&&(te.set(e,n),e.style.height=i+"px",e.style.width=t+"px",e.style.marginLeft=s?-t/2+"px":0,e.style.marginTop=s?-i/2+"px":0)}const se={passive:!0},ne={...se,capture:!0};function oe(e,t,i,s){t.addEventListener(e,i,s?ne:se)}function le(e,t,i,s){t.removeEventListener(e,i,se)}function re(e,t,i,s){let n;i=i||0;let o=(s=s||t.length-1)<=2147483647;for(;s-i>1;)n=o?i+s>>1:Se((i+s)/2),t[n]=t&&n<=i;n+=s)if(null!=e[n])return n;return-1}function ue(e,t,i,s){let n=Ie(e),o=Ie(t);e==t&&(-1==n?(e*=i,t/=i):(e/=i,t*=i));let l=10==i?De:Me,r=1==o?Ae:Se,a=(1==n?Se:Ae)(l(Ee(e))),u=r(l(Ee(t))),c=Le(i,a),d=Le(i,u);return 10==i&&(a<0&&(c=Ge(c,-a)),u<0&&(d=Ge(d,-u))),s||2==i?(e=c*n,t=d*o):(e=We(e,c),t=Ve(t,d)),[e,t]}function ce(e,t,i,s){let n=ue(e,t,i,s);return 0==e&&(n[0]=0),0==t&&(n[1]=0),n}j&&function e(){let t=devicePixelRatio;Y!=t&&(Y=t,B&&le(U,B,e),B=matchMedia(`(min-resolution: ${Y-.001}dppx) and (max-resolution: ${Y+.001}dppx)`),oe(U,B,e),z.dispatchEvent(new CustomEvent(N)))}();const de=.1,he={mode:3,pad:de},fe={pad:0,soft:null,mode:0},pe={min:fe,max:fe};function ge(e,t,i,s){return ot(i)?_e(e,t,i):(fe.pad=i,fe.soft=s?0:null,fe.mode=s?3:0,_e(e,t,pe))}function me(e,t){return null==e?t:e}function _e(e,t,i){let s=i.min,n=i.max,o=me(s.pad,0),l=me(n.pad,0),r=me(s.hard,-Re),a=me(n.hard,Re),u=me(s.soft,Re),c=me(n.soft,-Re),d=me(s.mode,0),h=me(n.mode,0),f=t-e,p=De(f),g=Oe(Ee(e),Ee(t)),m=De(g),_=Ee(m-p);(f<1e-24||_>10)&&(f=0,0!=e&&0!=t||(f=1e-24,2==d&&u!=Re&&(o=0),2==h&&c!=-Re&&(l=0)));let v=f||g||1e3,y=De(v),b=Le(10,Se(y)),w=Ge(We(e-v*(0==f?0==e?.1:1:o),b/10),24),E=e>=u&&(1==d||3==d&&w<=u||2==d&&w>=u)?u:Re,S=Oe(r,w=E?E:Te(E,w)),x=Ge(Ve(t+v*(0==f?0==t?.1:1:l),b/10),24),A=t<=c&&(1==h||3==h&&x>=c||2==h&&x<=c)?c:-Re,T=Te(a,x>A&&t<=A?A:Oe(A,x));return S==T&&0==S&&(T=100),[S,T]}const ve=new Intl.NumberFormat(j?H.language:"en-US"),ye=e=>ve.format(e),be=Math,we=be.PI,Ee=be.abs,Se=be.floor,xe=be.round,Ae=be.ceil,Te=be.min,Oe=be.max,Le=be.pow,Ie=be.sign,De=be.log10,Me=be.log2,ke=(e,t=1)=>be.sinh(e)*t,Ce=(e,t=1)=>be.asinh(e/t),Re=1/0;function Fe(e){return 1+(0|De((e^e>>31)-(e>>31)))}function Pe(e,t,i){return Te(Oe(e,t),i)}function Ue(e){return"function"==typeof e?e:()=>e}const Ne=e=>e,$e=(e,t)=>t,je=e=>null,Xe=e=>!0,ze=(e,t)=>e==t,He=/\.\d*?(?=9{6,}|0{6,})/gm,Ye=e=>{if(it(e)||Ke.has(e))return e;const t=`${e}`,i=t.match(He);if(null==i)return e;let s=i[0].length-1;if(-1!=t.indexOf("e-")){let[e,i]=t.split("e");return+`${Ye(e)}e${i}`}return Ge(e,s)};function Be(e,t){return Ye(Ge(Ye(e/t))*t)}function Ve(e,t){return Ye(Ae(Ye(e/t))*t)}function We(e,t){return Ye(Se(Ye(e/t))*t)}function Ge(e,t=0){if(it(e))return e;let i=10**t,s=e*i*(1+Number.EPSILON);return xe(s)/i}const Ke=new Map;function qe(e){return((""+e).split(".")[1]||"").length}function Ze(e,t,i,s){let n=[],o=s.map(qe);for(let l=t;l=0?0:t)+(l>=o[r]?0:o[r]),c=10==e?a:Ge(a,u);n.push(c),Ke.set(c,u)}}return n}const Je={},Qe=[],et=[null,null],tt=Array.isArray,it=Number.isInteger,st=e=>void 0===e;function nt(e){return"string"==typeof e}function ot(e){let t=!1;if(null!=e){let i=e.constructor;t=null==i||i==Object}return t}function lt(e){return null!=e&&"object"==typeof e}const rt=Object.getPrototypeOf(Uint8Array),at="__proto__";function ut(e,t=ot){let i;if(tt(e)){let s=e.find((e=>null!=e));if(tt(s)||t(s)){i=Array(e.length);for(let s=0;so){for(s=l-1;s>=0&&null==e[s];)e[s--]=null;for(s=l+1;sPromise.resolve().then(e):queueMicrotask;const ft=["January","February","March","April","May","June","July","August","September","October","November","December"],pt=["Sunday","Monday","Tuesday","Wednesday","Thursday","Friday","Saturday"];function gt(e){return e.slice(0,3)}const mt=pt.map(gt),_t=ft.map(gt),vt={MMMM:ft,MMM:_t,WWWW:pt,WWW:mt};function yt(e){return(e<10?"0":"")+e}const bt={YYYY:e=>e.getFullYear(),YY:e=>(e.getFullYear()+"").slice(2),MMMM:(e,t)=>t.MMMM[e.getMonth()],MMM:(e,t)=>t.MMM[e.getMonth()],MM:e=>yt(e.getMonth()+1),M:e=>e.getMonth()+1,DD:e=>yt(e.getDate()),D:e=>e.getDate(),WWWW:(e,t)=>t.WWWW[e.getDay()],WWW:(e,t)=>t.WWW[e.getDay()],HH:e=>yt(e.getHours()),H:e=>e.getHours(),h:e=>{let t=e.getHours();return 0==t?12:t>12?t-12:t},AA:e=>e.getHours()>=12?"PM":"AM",aa:e=>e.getHours()>=12?"pm":"am",a:e=>e.getHours()>=12?"p":"a",mm:e=>yt(e.getMinutes()),m:e=>e.getMinutes(),ss:e=>yt(e.getSeconds()),s:e=>e.getSeconds(),fff:e=>{return((t=e.getMilliseconds())<10?"00":t<100?"0":"")+t;var t}};function wt(e,t){t=t||vt;let i,s=[],n=/\{([a-z]+)\}|[^{]+/gi;for(;i=n.exec(e);)s.push("{"==i[0][0]?bt[i[1]]:i[0]);return e=>{let i="";for(let n=0;ne%1==0,xt=[1,2,2.5,5],At=Ze(10,-32,0,xt),Tt=Ze(10,0,32,xt),Ot=Tt.filter(St),Lt=At.concat(Tt),It="{YYYY}",Dt="\n"+It,Mt="{M}/{D}",kt="\n"+Mt,Ct=kt+"/{YY}",Rt="{aa}",Ft="{h}:{mm}"+Rt,Pt="\n"+Ft,Ut=":{ss}",Nt=null;function $t(e){let t=1e3*e,i=60*t,s=60*i,n=24*s,o=30*n,l=365*n;return[(1==e?Ze(10,0,3,xt).filter(St):Ze(10,-3,0,xt)).concat([t,5*t,10*t,15*t,30*t,i,5*i,10*i,15*i,30*i,s,2*s,3*s,4*s,6*s,8*s,12*s,n,2*n,3*n,4*n,5*n,6*n,7*n,8*n,9*n,10*n,15*n,o,2*o,3*o,4*o,6*o,l,2*l,5*l,10*l,25*l,50*l,100*l]),[[l,It,Nt,Nt,Nt,Nt,Nt,Nt,1],[28*n,"{MMM}",Dt,Nt,Nt,Nt,Nt,Nt,1],[n,Mt,Dt,Nt,Nt,Nt,Nt,Nt,1],[s,"{h}"+Rt,Ct,Nt,kt,Nt,Nt,Nt,1],[i,Ft,Ct,Nt,kt,Nt,Nt,Nt,1],[t,Ut,Ct+" "+Ft,Nt,kt+" "+Ft,Nt,Pt,Nt,1],[e,Ut+".{fff}",Ct+" "+Ft,Nt,kt+" "+Ft,Nt,Pt,Nt,1]],function(t){return(r,a,u,c,d,h)=>{let f=[],p=d>=l,g=d>=o&&d=n?n:d,l=y+(Se(u)-Se(_))+Ve(_-y,o);f.push(l);let p=t(l),g=p.getHours()+p.getMinutes()/i+p.getSeconds()/s,m=d/s,v=h/r.axes[a]._space;for(;l=Ge(l+d,1==e?0:3),!(l>c);)if(m>1){let e=Se(Ge(g+m,6))%24,i=t(l).getHours()-e;i>1&&(i=-1),l-=i*s,g=(g+m)%24,Ge((l-f[f.length-1])/d,3)*v>=.7&&f.push(l)}else f.push(l)}return f}}]}const[jt,Xt,zt]=$t(1),[Ht,Yt,Bt]=$t(.001);function Vt(e,t){return e.map((e=>e.map(((i,s)=>0==s||8==s||null==i?i:t(1==s||0==e[8]?i:e[1]+i)))))}function Wt(e,t){return(i,s,n,o,l)=>{let r,a,u,c,d,h,f=t.find((e=>l>=e[0]))||t[t.length-1];return s.map((t=>{let i=e(t),s=i.getFullYear(),n=i.getMonth(),o=i.getDate(),l=i.getHours(),p=i.getMinutes(),g=i.getSeconds(),m=s!=r&&f[2]||n!=a&&f[3]||o!=u&&f[4]||l!=c&&f[5]||p!=d&&f[6]||g!=h&&f[7]||f[1];return r=s,a=n,u=o,c=l,d=p,h=g,m(i)}))}}function Gt(e,t,i){return new Date(e,t,i)}function Kt(e,t){return t(e)}Ze(2,-53,53,[1]);const qt="{YYYY}-{MM}-{DD} {h}:{mm}{aa}";function Zt(e,t){return(i,s,n,o)=>null==o?$:t(e(s))}const Jt={show:!0,live:!0,isolate:!1,mount:()=>{},markers:{show:!0,width:2,stroke:function(e,t){let i=e.series[t];return i.width?i.stroke(e,t):i.points.width?i.points.stroke(e,t):null},fill:function(e,t){return e.series[t].fill(e,t)},dash:"solid"},idx:null,idxs:null,values:[]};const Qt=[0,0];function ei(e,t,i,s=!0){return e=>{0==e.button&&(!s||e.target==t)&&i(e)}}function ti(e,t,i,s=!0){return e=>{(!s||e.target==t)&&i(e)}}const ii={show:!0,x:!0,y:!0,lock:!1,move:function(e,t,i){return Qt[0]=t,Qt[1]=i,Qt},points:{one:!1,show:function(e,t){let i=e.cursor.points,s=q(),n=i.size(e,t);G(s,S,n),G(s,x,n);let o=n/-2;G(s,"marginLeft",o),G(s,"marginTop",o);let l=i.width(e,t,n);return l&&G(s,"borderWidth",l),s},size:function(e,t){return e.series[t].points.size},width:0,stroke:function(e,t){let i=e.series[t].points;return i._stroke||i._fill},fill:function(e,t){let i=e.series[t].points;return i._fill||i._stroke}},bind:{mousedown:ei,mouseup:ei,click:ei,dblclick:ei,mousemove:ti,mouseleave:ti,mouseenter:ti},drag:{setScale:!0,x:!0,y:!1,dist:0,uni:null,click:(e,t)=>{t.stopPropagation(),t.stopImmediatePropagation()},_x:!1,_y:!1},focus:{dist:(e,t,i,s,n)=>s-n,prox:-1,bias:0},hover:{skip:[void 0],prox:null,bias:0},left:-10,top:-10,idx:null,dataIdx:null,idxs:null,event:null},si={show:!0,stroke:"rgba(0,0,0,0.07)",width:2},ni=ct({},si,{filter:$e}),oi=ct({},ni,{size:10}),li=ct({},si,{show:!1}),ri='12px system-ui, -apple-system, "Segoe UI", Roboto, "Helvetica Neue", Arial, "Noto Sans", sans-serif, "Apple Color Emoji", "Segoe UI Emoji", "Segoe UI Symbol", "Noto Color Emoji"',ai="bold "+ri,ui={show:!0,scale:"x",stroke:I,space:50,gap:5,size:50,labelGap:0,labelSize:30,labelFont:ai,side:2,grid:ni,ticks:oi,border:li,font:ri,lineGap:1.5,rotate:0},ci="Value",di="Time",hi={show:!0,scale:"x",auto:!1,sorted:1,min:Re,max:-Re,idxs:[]};function fi(e,t,i,s,n){return t.map((e=>null==e?"":ye(e)))}function pi(e,t,i,s,n,o,l){let r=[],a=Ke.get(n)||0;for(let u=i=l?i:Ge(Ve(i,n),a);u<=s;u=Ge(u+n,a))r.push(Object.is(u,-0)?0:u);return r}function gi(e,t,i,s,n,o,l){const r=[],a=e.scales[e.axes[t].scale].log,u=Se((10==a?De:Me)(i));n=Le(a,u),10==a&&(n=Lt[re(n,Lt)]);let c=i,d=n*a;10==a&&(d=Lt[re(d,Lt)]);do{r.push(c),c+=n,10!=a||Ke.has(c)||(c=Ge(c,Ke.get(n))),c>=d&&(d=(n=c)*a,10==a&&(d=Lt[re(d,Lt)]))}while(c<=s);return r}function mi(e,t,i,s,n,o,l){let r=e.scales[e.axes[t].scale].asinh,a=s>r?gi(e,t,Oe(r,i),s,n):[r],u=s>=0&&i<=0?[0]:[];return(i<-r?gi(e,t,Oe(r,-s),-i,n):[r]).reverse().map((e=>-e)).concat(u,a)}const _i=/./,vi=/[12357]/,yi=/[125]/,bi=/1/,wi=(e,t,i,s)=>e.map(((e,n)=>4==t&&0==e||n%s==0&&i.test(e.toExponential()[e<0?1:0])?e:null));function Ei(e,t,i,s,n){let o=e.axes[i],l=o.scale,r=e.scales[l],a=e.valToPos,u=o._space,c=a(10,l),d=a(9,l)-c>=u?_i:a(7,l)-c>=u?vi:a(5,l)-c>=u?yi:bi;if(d==bi){let e=Ee(a(1,l)-c);if(en,Li={show:!0,auto:!0,sorted:0,gaps:Oi,alpha:1,facets:[ct({},Ti,{scale:"x"}),ct({},Ti,{scale:"y"})]},Ii={scale:"y",auto:!0,sorted:0,show:!0,spanGaps:!1,gaps:Oi,alpha:1,points:{show:function(e,t){let{scale:i,idxs:s}=e.series[0],n=e._data[0],o=e.valToPos(n[s[0]],i,!0),l=e.valToPos(n[s[1]],i,!0),r=Ee(l-o)/(e.series[t].points.space*Y);return s[1]-s[0]<=r},filter:null},values:null,min:Re,max:-Re,idxs:[],path:null,clip:null};function Di(e,t,i,s,n){return i/10}const Mi={time:!0,auto:!0,distr:1,log:10,asinh:1,min:null,max:null,dir:1,ori:0},ki=ct({},Mi,{time:!1,ori:1}),Ci={};function Ri(e,t){let i=Ci[e];return i||(i={key:e,plots:[],sub(e){i.plots.push(e)},unsub(e){i.plots=i.plots.filter((t=>t!=e))},pub(e,t,s,n,o,l,r){for(let a=0;a{let g=e.pxRound;const m=r.dir*(0==r.ori?1:-1),_=0==r.ori?Wi:Gi;let v,y;1==m?(v=i,y=s):(v=s,y=i);let b=g(u(t[v],r,f,d)),w=g(c(l[v],a,p,h)),E=g(u(t[y],r,f,d)),S=g(c(1==o?a.max:a.min,a,p,h)),x=new Path2D(n);return _(x,E,S),_(x,b,S),_(x,b,w),x}))}function Xi(e,t,i,s,n,o){let l=null;if(e.length>0){l=new Path2D;const r=0==t?Ki:qi;let a=i;for(let t=0;ti[0]){let e=i[0]-a;e>0&&r(l,a,s,e,s+o),a=i[1]}}let u=i+n-a,c=10;u>0&&r(l,a,s-c/2,u,s+o+c)}return l}function zi(e,t,i,s,n,o,l){let r=[],a=e.length;for(let u=1==n?i:s;u>=i&&u<=s;u+=n){if(null===t[u]){let c=u,d=u;if(1==n)for(;++u<=s&&null===t[u];)d=u;else for(;--u>=i&&null===t[u];)d=u;let h=o(e[c]),f=d==c?h:o(e[d]),p=c-n;h=l<=0&&p>=0&&p=0&&g>=0&&g=h&&r.push([h,f])}}return r}function Hi(e){return 0==e?Ne:1==e?xe:t=>Be(t,e)}function Yi(e){let t=0==e?Bi:Vi,i=0==e?(e,t,i,s,n,o)=>{e.arcTo(t,i,s,n,o)}:(e,t,i,s,n,o)=>{e.arcTo(i,t,n,s,o)},s=0==e?(e,t,i,s,n)=>{e.rect(t,i,s,n)}:(e,t,i,s,n)=>{e.rect(i,t,n,s)};return(e,n,o,l,r,a=0,u=0)=>{0==a&&0==u?s(e,n,o,l,r):(a=Te(a,l/2,r/2),u=Te(u,l/2,r/2),t(e,n+a,o),i(e,n+l,o,n+l,o+r,a),i(e,n+l,o+r,n,o+r,u),i(e,n,o+r,n,o,u),i(e,n,o,n+l,o,a),e.closePath())}}const Bi=(e,t,i)=>{e.moveTo(t,i)},Vi=(e,t,i)=>{e.moveTo(i,t)},Wi=(e,t,i)=>{e.lineTo(t,i)},Gi=(e,t,i)=>{e.lineTo(i,t)},Ki=Yi(0),qi=Yi(1),Zi=(e,t,i,s,n,o)=>{e.arc(t,i,s,n,o)},Ji=(e,t,i,s,n,o)=>{e.arc(i,t,s,n,o)},Qi=(e,t,i,s,n,o,l)=>{e.bezierCurveTo(t,i,s,n,o,l)},es=(e,t,i,s,n,o,l)=>{e.bezierCurveTo(i,t,n,s,l,o)};function ts(e){return(e,t,i,s,n)=>Ui(e,t,((t,o,l,r,a,u,c,d,h,f,p)=>{let g,m,{pxRound:_,points:v}=t;0==r.ori?(g=Bi,m=Zi):(g=Vi,m=Ji);const y=Ge(v.width*Y,3);let b=(v.size-v.width)/2*Y,w=Ge(2*b,3),E=new Path2D,S=new Path2D,{left:x,top:A,width:T,height:O}=e.bbox;Ki(S,x-w,A-w,T+2*w,O+2*w);const L=e=>{if(null!=l[e]){let t=_(u(o[e],r,f,d)),i=_(c(l[e],a,p,h));g(E,t+b,i),m(E,t,i,b,0,2*we)}};if(n)n.forEach(L);else for(let e=i;e<=s;e++)L(e);return{stroke:y>0?E:null,fill:E,clip:S,flags:Fi|Pi}}))}function is(e){return(t,i,s,n,o,l)=>{s!=n&&(o!=s&&l!=s&&e(t,i,s),o!=n&&l!=n&&e(t,i,n),e(t,i,l))}}const ss=is(Wi),ns=is(Gi);function os(e){const t=me(e?.alignGaps,0);return(e,i,s,n)=>Ui(e,i,((o,l,r,a,u,c,d,h,f,p,g)=>{let m,_,v=o.pxRound,y=e=>v(c(e,a,p,h)),b=e=>v(d(e,u,g,f));0==a.ori?(m=Wi,_=ss):(m=Gi,_=ns);const w=a.dir*(0==a.ori?1:-1),E={stroke:new Path2D,fill:null,clip:null,band:null,gaps:null,flags:Fi},S=E.stroke;let x,A,T,O=Re,L=-Re,I=y(l[1==w?s:n]),D=ae(r,s,n,1*w),M=ae(r,s,n,-1*w),k=y(l[D]),C=y(l[M]),R=!1;for(let e=1==w?s:n;e>=s&&e<=n;e+=w){let t=y(l[e]),i=r[e];t==I?null!=i?(A=b(i),O==Re&&(m(S,t,A),x=A),O=Te(A,O),L=Oe(A,L)):null===i&&(R=!0):(O!=Re&&(_(S,I,O,L,x,A),T=I),null!=i?(A=b(i),m(S,t,A),O=L=x=A):(O=Re,L=-Re,null===i&&(R=!0)),I=t)}O!=Re&&O!=L&&T!=I&&_(S,I,O,L,x,A);let[F,P]=Ni(e,i);if(null!=o.fill||0!=F){let t=E.fill=new Path2D(S),s=b(o.fillTo(e,i,o.min,o.max,F));m(t,C,s),m(t,k,s)}if(!o.spanGaps){let u=[];R&&u.push(...zi(l,r,s,n,w,y,t)),E.gaps=u=o.gaps(e,i,s,n,u),E.clip=Xi(u,a.ori,h,f,p,g)}return 0!=P&&(E.band=2==P?[ji(e,i,s,n,S,-1),ji(e,i,s,n,S,1)]:ji(e,i,s,n,S,P)),E}))}function ls(e,t,i,s,n,o,l=Re){if(e.length>1){let r=null;for(let a=0,u=1/0;a0!==s[e]>0?i[e]=0:(i[e]=3*(a[e-1]+a[e])/((2*a[e]+a[e-1])/s[e-1]+(a[e]+2*a[e-1])/s[e]),isFinite(i[e])||(i[e]=0));i[l-1]=s[l-2];for(let u=0;u{xs.pxRatio=Y})));const cs=os(),ds=ts();function hs(e,t,i,s){return(s?[e[0],e[1]].concat(e.slice(2)):[e[0]].concat(e.slice(1))).map(((e,s)=>fs(e,s,t,i)))}function fs(e,t,i,s){return ct({},0==t?i:s,e)}function ps(e,t,i){return null==t?et:[t,i]}const gs=ps;function ms(e,t,i){return null==t?et:ge(t,i,de,!0)}function _s(e,t,i,s){return null==t?et:ue(t,i,e.scales[s].log,!1)}const vs=_s;function ys(e,t,i,s){return null==t?et:ce(t,i,e.scales[s].log,!1)}const bs=ys;function ws(e,t,i,s,n){let o=Oe(Fe(e),Fe(t)),l=t-e,r=re(n/s*l,i);do{let e=i[r],t=s*e/l;if(t>=n&&o+(e<5?Ke.get(e):0)<=17)return[e,t]}while(++r(t=xe((i=+s)*Y))+"px")),t,i]}function Ss(e){e.show&&[e.font,e.labelFont].forEach((e=>{let t=Ge(e[2]*Y,1);e[0]=e[0].replace(/[0-9.]+px/,t+"px"),e[1]=t}))}function xs(e,t,i){const I={mode:me(e.mode,1)},U=I.mode;function j(e,t){return((3==t.distr?De(e>0?e:t.clamp(I,e,t.min,t.max,t.key)):4==t.distr?Ce(e,t.asinh):100==t.distr?t.fwd(e):e)-t._min)/(t._max-t._min)}function H(e,t,i,s){let n=j(e,t);return s+i*(-1==t.dir?1-n:n)}function B(e,t,i,s){let n=j(e,t);return s+i*(-1==t.dir?n:1-n)}function Z(e,t,i,s){return 0==t.ori?H(e,t,i,s):B(e,t,i,s)}I.valToPosH=H,I.valToPosV=B;let Q=!1;I.status=0;const te=I.root=q(s);if(null!=e.id&&(te.id=e.id),V(te,e.class),e.title){q(l,te).textContent=e.title}const se=K("canvas"),ne=I.ctx=se.getContext("2d"),ae=q(r,te);oe("click",ae,(e=>{if(e.target===pe){(an!=nn||un!=on)&&vn.click(I,e)}}),!0);const fe=I.under=q(a,ae);ae.appendChild(se);const pe=I.over=q(u,ae),_e=+me((e=ut(e)).pxAlign,1),ve=Hi(_e);(e.plugins||[]).forEach((t=>{t.opts&&(e=t.opts(I,e)||e)}));const ye=e.ms||.001,be=I.series=1==U?hs(e.series||[],hi,Ii,!1):(Se=e.series||[null],Ie=Li,Se.map(((e,t)=>0==t?{}:ct({},Ie,e))));var Se,Ie;const Me=I.axes=hs(e.axes||[],ui,Ai,!0),Fe=I.scales={},Ne=I.bands=e.bands||[];Ne.forEach((e=>{e.fill=Ue(e.fill||null),e.dir=me(e.dir,-1)}));const He=2==U?be[1].facets[0].scale:be[0].scale,Ye={axes:function(){for(let e=0;eCs[e])):p,m=2==c.distr?Cs[p[1]]-Cs[p[0]]:a,_=t.ticks,v=t.border,y=_.show?xe(_.size*Y):0,b=t._rotate*-we/180,w=ve(t._pos*Y),E=w+(y+f)*r;s=0==o?E:0,i=1==o?E:0,Ns(t.font[0],l,1==t.align?O:2==t.align?L:b>0?O:b<0?L:0==o?"center":3==n?L:O,b||1==o?"middle":2==n?A:T);let S=t.font[1]*t.lineGap,x=p.map((e=>ve(Z(e,c,d,h)))),D=t._values;for(let e=0;e0&&(be.forEach(((e,i)=>{if(i>0&&e.show&&(Xs(i,!1),Xs(i,!0),null==e._paths)){ks!=e.alpha&&(ne.globalAlpha=ks=e.alpha);let s=2==U?[0,t[i][0].length-1]:function(e){let t=Pe(os-1,0,ns-1),i=Pe(ls+1,0,ns-1);for(;null==e[t]&&t>0;)t--;for(;null==e[i]&&i{if(t>0&&e.show){ks!=e.alpha&&(ne.globalAlpha=ks=e.alpha),null!=e._paths&&zs(t,!1);{let i=null!=e._paths?e._paths.gaps:null,s=e.points.show(I,t,os,ls,i),n=e.points.filter(I,t,s,i);(s||n)&&(e.points._paths=e.points.paths(I,t,os,ls,n),zs(t,!0))}1!=ks&&(ne.globalAlpha=ks=1),eo("drawSeries",t)}})))}},Ve=(e.drawOrder||["axes","series"]).map((e=>Ye[e]));function We(t){let i=Fe[t];if(null==i){let s=(e.scales||Je)[t]||Je;if(null!=s.from)We(s.from),Fe[t]=ct({},Fe[s.from],s,{key:t});else{i=Fe[t]=ct({},t==He?Mi:ki,s),i.key=t;let e=i.time,n=i.range,o=tt(n);if((t!=He||2==U&&!e)&&(!o||null!=n[0]&&null!=n[1]||(n={min:null==n[0]?he:{mode:1,hard:n[0],soft:n[0]},max:null==n[1]?he:{mode:1,hard:n[1],soft:n[1]}},o=!1),!o&&ot(n))){let e=n;n=(t,i,s)=>null==i?et:ge(i,s,e)}i.range=Ue(n||(e?gs:t==He?3==i.distr?vs:4==i.distr?bs:ps:3==i.distr?_s:4==i.distr?ys:ms)),i.auto=Ue(!o&&i.auto),i.clamp=Ue(i.clamp||Di),i._min=i._max=null}}}We("x"),We("y"),1==U&&be.forEach((e=>{We(e.scale)})),Me.forEach((e=>{We(e.scale)}));for(let s in e.scales)We(s);const Ze=Fe[He],it=Ze.distr;let rt,at;0==Ze.ori?(V(te,n),rt=H,at=B):(V(te,o),rt=B,at=H);const dt={};for(let s in Fe){let e=Fe[s];null==e.min&&null==e.max||(dt[s]={min:e.min,max:e.max},e.min=e.max=null)}const ft=e.tzDate||(e=>new Date(xe(e/ye))),pt=e.fmtDate||wt,gt=1==ye?zt(ft):Bt(ft),mt=Wt(ft,Vt(1==ye?Xt:Yt,pt)),_t=Zt(ft,Kt(qt,pt)),vt=[],yt=I.legend=ct({},Jt,e.legend),bt=yt.show,Et=yt.markers;let St,xt,At;yt.idxs=vt,Et.width=Ue(Et.width),Et.dash=Ue(Et.dash),Et.stroke=Ue(Et.stroke),Et.fill=Ue(Et.fill);let Tt,It=[],Dt=[],Mt=!1,kt={};if(yt.live){const e=be[1]?be[1].values:null;Mt=null!=e,Tt=Mt?e(I,1,0):{_:0};for(let t in Tt)kt[t]=$}if(bt)if(St=K("table",m,te),At=K("tbody",null,St),yt.mount(I,St),Mt){xt=K("thead",null,St,At);let e=K("tr",null,xt);for(var Ct in K("th",null,e),Tt)K("th",w,e).textContent=Ct}else V(St,v),yt.live&&V(St,_);const Rt={show:!0},Ft={show:!1};const Pt=new Map;function Ut(e,t,i,s=!0){const n=Pt.get(t)||{},o=zi.bind[e](I,t,i,s);o&&(oe(e,t,n[e]=o),Pt.set(t,n))}function Nt(e,t,i){const s=Pt.get(t)||{};for(let n in s)null!=e&&n!=e||(le(n,t,s[n]),delete s[n]);null==e&&Pt.delete(t)}let $t=0,Gt=0,Qt=0,ei=0,ti=0,si=0,ni=ti,oi=si,li=Qt,ri=ei,ai=0,_i=0,vi=0,yi=0;I.bbox={};let bi=!1,wi=!1,Ti=!1,Oi=!1,Ci=!1,Ui=!1;function Ni(e,t,i){(i||e!=I.width||t!=I.height)&&ji(e,t),qs(!1),Ti=!0,wi=!0,pn()}function ji(e,t){I.width=$t=Qt=e,I.height=Gt=ei=t,ti=si=0,function(){let e=!1,t=!1,i=!1,s=!1;Me.forEach(((n,o)=>{if(n.show&&n._show){let{side:o,_size:l}=n,r=o%2,a=l+(null!=n.label?n.labelSize:0);a>0&&(r?(Qt-=a,3==o?(ti+=a,s=!0):i=!0):(ei-=a,0==o?(si+=a,e=!0):t=!0))}})),es[0]=e,es[1]=i,es[2]=t,es[3]=s,Qt-=ss[1]+ss[3],ti+=ss[3],ei-=ss[2]+ss[0],si+=ss[0]}(),function(){let e=ti+Qt,t=si+ei,i=ti,s=si;function n(n,o){switch(n){case 1:return e+=o,e-o;case 2:return t+=o,t-o;case 3:return i-=o,i+o;case 0:return s-=o,s+o}}Me.forEach(((e,t)=>{if(e.show&&e._show){let t=e.side;e._pos=n(t,e._size),null!=e.label&&(e._lpos=n(t,e.labelSize))}}))}();let i=I.bbox;ai=i.left=Be(ti*Y,.5),_i=i.top=Be(si*Y,.5),vi=i.width=Be(Qt*Y,.5),yi=i.height=Be(ei*Y,.5)}const Xi=3;I.setSize=function({width:e,height:t}){Ni(e,t)};const zi=I.cursor=ct({},ii,{drag:{y:2==U}},e.cursor);if(null==zi.dataIdx){let e=zi.hover,i=e.skip=new Set(e.skip??[]);i.add(void 0);let s=e.prox=Ue(e.prox),n=e.bias??=0;zi.dataIdx=(e,o,l,r)=>{if(0==o)return l;let a=l,u=s(e,o,l,r)??Re,c=u>=0&&u0;)i.has(p[e])||(t=e);if(0==n||1==n)for(e=l;null==s&&e++u&&(a=null)}return a}}const Yi=e=>{zi.event=e};zi.idxs=vt,zi._lock=!1;let Bi=zi.points;Bi.show=Ue(Bi.show),Bi.size=Ue(Bi.size),Bi.stroke=Ue(Bi.stroke),Bi.width=Ue(Bi.width),Bi.fill=Ue(Bi.fill);const Vi=I.focus=ct({},e.focus||{alpha:.3},zi.focus),Wi=Vi.prox>=0,Gi=Wi&&Bi.one;let Ki=[],qi=[],Zi=[];function Ji(e,t){let i=Bi.show(I,t);if(i)return V(i,g),V(i,e.class),J(i,-10,-10,Qt,ei),pe.insertBefore(i,Ki[t]),i}function Qi(e,t){if(1==U||t>0){let t=1==U&&Fe[e.scale].time,i=e.value;e.value=t?nt(i)?Zt(ft,Kt(i,pt)):i||_t:i||xi,e.label=e.label||(t?di:ci)}if(Gi||t>0){e.width=null==e.width?1:e.width,e.paths=e.paths||cs||je,e.fillTo=Ue(e.fillTo||$i),e.pxAlign=+me(e.pxAlign,_e),e.pxRound=Hi(e.pxAlign),e.stroke=Ue(e.stroke||null),e.fill=Ue(e.fill||null),e._stroke=e._fill=e._paths=e._focus=null;let t=Ge((3+2*(Oe(1,e.width)||1))*1,3),i=e.points=ct({},{size:t,width:Oe(1,.2*t),stroke:e.stroke,space:2*t,paths:ds,_stroke:null,_fill:null},e.points);i.show=Ue(i.show),i.filter=Ue(i.filter),i.fill=Ue(i.fill),i.stroke=Ue(i.stroke),i.paths=Ue(i.paths),i.pxAlign=e.pxAlign}if(bt){let i=function(e,t){if(0==t&&(Mt||!yt.live||2==U))return et;let i=[],s=K("tr",y,At,At.childNodes[t]);V(s,e.class),e.show||V(s,d);let n=K("th",null,s);if(Et.show){let e=q(b,n);if(t>0){let i=Et.width(I,t);i&&(e.style.border=i+"px "+Et.dash(I,t)+" "+Et.stroke(I,t)),e.style.background=Et.fill(I,t)}}let o=q(w,n);for(var l in o.textContent=e.label,t>0&&(Et.show||(o.style.color=e.width>0?Et.stroke(I,t):Et.fill(I,t)),Ut("click",n,(t=>{if(zi._lock)return;Yi(t);let i=be.indexOf(e);if((t.ctrlKey||t.metaKey)!=yt.isolate){let e=be.some(((e,t)=>t>0&&t!=i&&e.show));be.forEach(((t,s)=>{s>0&&An(s,e?s==i?Rt:Ft:Rt,!0,io.setSeries)}))}else An(i,{show:!e.show},!0,io.setSeries)}),!1),Wi&&Ut(R,n,(t=>{zi._lock||(Yi(t),An(be.indexOf(e),In,!0,io.setSeries))}),!1)),Tt){let e=K("td",E,s);e.textContent="--",i.push(e)}return[s,i]}(e,t);It.splice(t,0,i[0]),Dt.splice(t,0,i[1]),yt.values.push(null)}if(zi.show){vt.splice(t,0,null);let i=null;Gi?0==t&&(i=Ji(e,t)):t>0&&(i=Ji(e,t)),Ki.splice(t,0,i),qi.splice(t,0,0),Zi.splice(t,0,0)}eo("addSeries",t)}I.addSeries=function(e,t){t=null==t?be.length:t,e=1==U?fs(e,t,hi,Ii):fs(e,t,{},Li),be.splice(t,0,e),Qi(be[t],t)},I.delSeries=function(e){if(be.splice(e,1),bt){yt.values.splice(e,1),Dt.splice(e,1);let t=It.splice(e,1)[0];Nt(null,t.firstChild),t.remove()}zi.show&&(vt.splice(e,1),Ki.splice(e,1)[0].remove(),qi.splice(e,1),Zi.splice(e,1)),eo("delSeries",e)};const es=[!1,!1,!1,!1];function ts(e,t,i,s){let[n,o,l,r]=i,a=t%2,u=0;return 0==a&&(r||o)&&(u=0==t&&!n||2==t&&!l?xe(ui.size/3):0),1==a&&(n||l)&&(u=1==t&&!o||3==t&&!r?xe(Ai.size/2):0),u}const is=I.padding=(e.padding||[ts,ts,ts,ts]).map((e=>Ue(me(e,ts)))),ss=I._padding=is.map(((e,t)=>e(I,t,es,0)));let ns,os=null,ls=null;const rs=1==U?be[0].idxs:null;let us,xs,As,Ts,Os,Ls,Is,Ds,Ms,ks,Cs=null,Rs=!1;function Fs(e,i){if(t=null==e?[]:e,I.data=I._data=t,2==U){ns=0;for(let e=1;e=0,Ui=!0,pn()}}function Ps(){let e,i;Rs=!0,1==U&&(ns>0?(os=rs[0]=0,ls=rs[1]=ns-1,e=t[0][os],i=t[0][ls],2==it?(e=os,i=ls):e==i&&(3==it?[e,i]=ue(e,e,Ze.log,!1):4==it?[e,i]=ce(e,e,Ze.log,!1):Ze.time?i=e+xe(86400/ye):[e,i]=ge(e,i,de,!0))):(os=rs[0]=e=null,ls=rs[1]=i=null)),xn(He,e,i)}function Us(e,t,i,s,n,o){e??=D,i??=Qe,s??="butt",n??=D,o??="round",e!=us&&(ne.strokeStyle=us=e),n!=xs&&(ne.fillStyle=xs=n),t!=As&&(ne.lineWidth=As=t),o!=Os&&(ne.lineJoin=Os=o),s!=Ls&&(ne.lineCap=Ls=s),i!=Ts&&ne.setLineDash(Ts=i)}function Ns(e,t,i,s){t!=xs&&(ne.fillStyle=xs=t),e!=Is&&(ne.font=Is=e),i!=Ds&&(ne.textAlign=Ds=i),s!=Ms&&(ne.textBaseline=Ms=s)}function $s(e,t,i,s,n=0){if(s.length>0&&e.auto(I,Rs)&&(null==t||null==t.min)){let t=me(os,0),o=me(ls,s.length-1),l=null==i.min?3==e.distr?function(e,t,i){let s=Re,n=-Re;for(let o=t;o<=i;o++){let t=e[o];null!=t&&t>0&&(tn&&(n=t))}return[s,n]}(s,t,o):function(e,t,i,s){let n=Re,o=-Re;if(1==s)n=e[t],o=e[i];else if(-1==s)n=e[i],o=e[t];else for(let l=t;l<=i;l++){let t=e[l];null!=t&&(to&&(o=t))}return[n,o]}(s,t,o,n):[i.min,i.max];e.min=Te(e.min,i.min=l[0]),e.max=Oe(e.max,i.max=l[1])}}I.setData=Fs;const js={min:null,max:null};function Xs(e,t){let i=t?be[e].points:be[e];i._stroke=i.stroke(I,e),i._fill=i.fill(I,e)}function zs(e,i){let s=i?be[e].points:be[e],{stroke:n,fill:o,clip:l,flags:r,_stroke:a=s._stroke,_fill:u=s._fill,_width:c=s.width}=s._paths;c=Ge(c*Y,3);let d=null,h=c%2/2;i&&null==u&&(u=c>0?"#fff":a);let f=1==s.pxAlign&&h>0;if(f&&ne.translate(h,h),!i){let e=ai-c/2,t=_i-c/2,i=vi+c,s=yi+c;d=new Path2D,d.rect(e,t,i,s)}i?Ys(a,c,s.dash,s.cap,u,n,o,r,l):function(e,i,s,n,o,l,r,a,u,c,d){let h=!1;0!=u&&Ne.forEach(((f,p)=>{if(f.series[0]==e){let e,g=be[f.series[1]],m=t[f.series[1]],_=(g._paths||Je).band;tt(_)&&(_=1==f.dir?_[0]:_[1]);let v=null;g.show&&_&&function(e,t,i){for(t=me(t,0),i=me(i,e.length-1);t<=i;){if(null!=e[t])return!0;t++}return!1}(m,os,ls)?(v=f.fill(I,p)||l,e=g._paths.clip):_=null,Ys(i,s,n,o,v,r,a,u,c,d,e,_),h=!0}})),h||Ys(i,s,n,o,l,r,a,u,c,d)}(e,a,c,s.dash,s.cap,u,n,o,r,d,l),f&&ne.translate(-h,-h)}const Hs=Fi|Pi;function Ys(e,t,i,s,n,o,l,r,a,u,c,d){Us(e,t,i,s,n),(a||u||d)&&(ne.save(),a&&ne.clip(a),u&&ne.clip(u)),d?(r&Hs)==Hs?(ne.clip(d),c&&ne.clip(c),Vs(n,l),Bs(e,o,t)):r&Pi?(Vs(n,l),ne.clip(d),Bs(e,o,t)):r&Fi&&(ne.save(),ne.clip(d),c&&ne.clip(c),Vs(n,l),ne.restore(),Bs(e,o,t)):(Vs(n,l),Bs(e,o,t)),(a||u||d)&&ne.restore()}function Bs(e,t,i){i>0&&(t instanceof Map?t.forEach(((e,t)=>{ne.strokeStyle=us=t,ne.stroke(e)})):null!=t&&e&&ne.stroke(t))}function Vs(e,t){t instanceof Map?t.forEach(((e,t)=>{ne.fillStyle=xs=t,ne.fill(e)})):null!=t&&e&&ne.fill(t)}function Ws(e,t,i,s,n,o,l,r,a,u){let c=l%2/2;1==_e&&ne.translate(c,c),Us(r,l,a,u,r),ne.beginPath();let d,h,f,p,g=n+(0==s||3==s?-o:o);0==i?(h=n,p=g):(d=n,f=g);for(let m=0;m{if(!i.show)return;let n=Fe[i.scale];if(null==n.min)return void(i._show&&(t=!1,i._show=!1,qs(!1)));i._show||(t=!1,i._show=!0,qs(!1));let o=i.side,l=o%2,{min:r,max:a}=n,[u,c]=function(e,t,i,s){let n,o=Me[e];if(s<=0)n=[0,0];else{let l=o._space=o.space(I,e,t,i,s);n=ws(t,i,o._incrs=o.incrs(I,e,t,i,s,l),s,l)}return o._found=n}(s,r,a,0==l?Qt:ei);if(0==c)return;let d=2==n.distr,h=i._splits=i.splits(I,s,r,a,u,c,d),f=2==n.distr?h.map((e=>Cs[e])):h,p=2==n.distr?Cs[h[1]]-Cs[h[0]]:u,g=i._values=i.values(I,i.filter(I,f,s,c,p),s,c,p);i._rotate=2==o?i.rotate(I,g,s,c):0;let m=i._size;i._size=Ae(i.size(I,g,s,e)),null!=m&&i._size!=m&&(t=!1)})),t}function Ks(e){let t=!0;return is.forEach(((i,s)=>{let n=i(I,s,es,e);n!=ss[s]&&(t=!1),ss[s]=n})),t}function qs(e){be.forEach(((t,i)=>{i>0&&(t._paths=null,e&&(1==U?(t.min=null,t.max=null):t.facets.forEach((e=>{e.min=null,e.max=null}))))}))}let Zs,Js,Qs,en,tn,sn,nn,on,ln,rn,an,un,cn=!1,dn=!1,hn=[];function fn(){dn=!1;for(let e=0;e0){be.forEach(((i,s)=>{if(1==U){let n=i.scale,o=dt[n];if(null==o)return;let l=e[n];if(0==s){let e=l.range(I,l.min,l.max,n);l.min=e[0],l.max=e[1],os=re(l.min,t[0]),ls=re(l.max,t[0]),ls-os>1&&(t[0][os]l.max&&ls--),i.min=Cs[os],i.max=Cs[ls]}else i.show&&i.auto&&$s(l,o,i,t[s],i.sorted);i.idxs[0]=os,i.idxs[1]=ls}else if(s>0&&i.show&&i.auto){let[n,o]=i.facets,l=n.scale,r=o.scale,[a,u]=t[s],c=e[l],d=e[r];null!=c&&$s(c,dt[l],n,a,n.sorted),null!=d&&$s(d,dt[r],o,u,o.sorted),i.min=o.min,i.max=o.max}}));for(let t in e){let i=e[t],s=dt[t];if(null==i.from&&(null==s||null==s.min)){let e=i.range(I,i.min==Re?null:i.min,i.max==-Re?null:i.max,t);i.min=e[0],i.max=e[1]}}}for(let t in e){let i=e[t];if(null!=i.from){let s=e[i.from];if(null==s.min)i.min=i.max=null;else{let e=i.range(I,s.min,s.max,t);i.min=e[0],i.max=e[1]}}}let i={},s=!1;for(let t in e){let n=e[t],o=Fe[t];if(o.min!=n.min||o.max!=n.max){o.min=n.min,o.max=n.max;let e=o.distr;o._min=3==e?De(o.min):4==e?Ce(o.min,o.asinh):100==e?o.fwd(o.min):o.min,o._max=3==e?De(o.max):4==e?Ce(o.max,o.asinh):100==e?o.fwd(o.max):o.max,i[t]=s=!0}}if(s){be.forEach(((e,t)=>{2==U?t>0&&i.y&&(e._paths=null):i[e.scale]&&(e._paths=null)}));for(let e in i)Ti=!0,eo("setScale",e);zi.show&&zi.left>=0&&(Oi=Ui=!0)}for(let t in dt)dt[t]=null}(),bi=!1),Ti&&(!function(){let e=!1,t=0;for(;!e;){t++;let i=Gs(t),s=Ks(t);e=t==Xi||i&&s,e||(ji(I.width,I.height),wi=!0)}}(),Ti=!1),wi){if(G(fe,O,ti),G(fe,A,si),G(fe,S,Qt),G(fe,x,ei),G(pe,O,ti),G(pe,A,si),G(pe,S,Qt),G(pe,x,ei),G(ae,S,$t),G(ae,x,Gt),se.width=xe($t*Y),se.height=xe(Gt*Y),Me.forEach((({_el:e,_show:t,_size:i,_pos:s,side:n})=>{if(null!=e)if(t){let t=n%2==1;G(e,t?"left":"top",s-(3===n||0===n?i:0)),G(e,t?"width":"height",i),G(e,t?"top":"left",t?si:ti),G(e,t?"height":"width",t?ei:Qt),W(e,d)}else V(e,d)})),us=xs=As=Os=Ls=Is=Ds=Ms=Ts=null,ks=1,$n(!0),ti!=ni||si!=oi||Qt!=li||ei!=ri){qs(!1);let e=Qt/li,t=ei/ri;if(zi.show&&!Oi&&zi.left>=0){zi.left*=e,zi.top*=t,Qs&&J(Qs,xe(zi.left),0,Qt,ei),en&&J(en,0,xe(zi.top),Qt,ei);for(let i=0;i=0&&wn.width>0){wn.left*=e,wn.width*=e,wn.top*=t,wn.height*=t;for(let e in zn)G(En,e,wn[e])}ni=ti,oi=si,li=Qt,ri=ei}eo("setSize"),wi=!1}$t>0&&Gt>0&&(ne.clearRect(0,0,se.width,se.height),eo("drawClear"),Ve.forEach((e=>e())),eo("draw")),wn.show&&Ci&&(Sn(wn),Ci=!1),zi.show&&Oi&&(Un(null,!0,!1),Oi=!1),yt.show&&yt.live&&Ui&&(Fn(),Ui=!1),Q||(Q=!0,I.status=1,eo("ready")),Rs=!1,cn=!1}function mn(e,i){let s=Fe[e];if(null==s.from){if(0==ns){let t=s.range(I,i.min,i.max,e);i.min=t[0],i.max=t[1]}if(i.min>i.max){let e=i.min;i.min=i.max,i.max=e}if(ns>1&&null!=i.min&&null!=i.max&&i.max-i.min<1e-16)return;e==He&&2==s.distr&&ns>0&&(i.min=re(i.min,t[0]),i.max=re(i.max,t[0]),i.min==i.max&&i.max++),dt[e]=i,bi=!0,pn()}}I.batch=function(e,t=!1){cn=!0,dn=t,e(I),gn(),t&&hn.length>0&&queueMicrotask(fn)},I.redraw=(e,t)=>{Ti=t||!1,!1!==e?xn(He,Ze.min,Ze.max):pn()},I.setScale=mn;let _n=!1;const vn=zi.drag;let yn=vn.x,bn=vn.y;zi.show&&(zi.x&&(Zs=q(f,pe)),zi.y&&(Js=q(p,pe)),0==Ze.ori?(Qs=Zs,en=Js):(Qs=Js,en=Zs),an=zi.left,un=zi.top);const wn=I.select=ct({show:!0,over:!0,left:0,width:0,top:0,height:0},e.select),En=wn.show?q(h,wn.over?pe:fe):null;function Sn(e,t){if(wn.show){for(let t in e)wn[t]=e[t],t in zn&&G(En,t,e[t]);!1!==t&&eo("setSelect")}}function xn(e,t,i){mn(e,{min:t,max:i})}function An(e,t,i,s){null!=t.focus&&function(e){if(e!=Ln){let t=null==e,i=1!=Vi.alpha;be.forEach(((s,n)=>{if(1==U||n>0){let o=t||0==n||n==e;s._focus=t?null:o,i&&function(e,t){be[e].alpha=t,zi.show&&Ki[e]&&(Ki[e].style.opacity=t);bt&&It[e]&&(It[e].style.opacity=t)}(n,o?1:Vi.alpha)}})),Ln=e,i&&pn()}}(e),null!=t.show&&be.forEach(((i,s)=>{s>0&&(e==s||null==e)&&(i.show=t.show,function(e){let t=be[e],i=bt?It[e]:null;t.show?i&&W(i,d):(i&&V(i,d),J(Gi?Ki[0]:Ki[e],-10,-10,Qt,ei))}(s,t.show),2==U?(xn(i.facets[0].scale,null,null),xn(i.facets[1].scale,null,null)):xn(i.scale,null,null),pn())})),!1!==i&&eo("setSeries",e,t),s&&oo("setSeries",I,e,t)}let Tn,On,Ln;I.setSelect=Sn,I.setSeries=An,I.addBand=function(e,t){e.fill=Ue(e.fill||null),e.dir=me(e.dir,-1),t=null==t?Ne.length:t,Ne.splice(t,0,e)},I.setBand=function(e,t){ct(Ne[e],t)},I.delBand=function(e){null==e?Ne.length=0:Ne.splice(e,1)};const In={focus:!0};function Dn(e,t,i){let s=Fe[t];i&&(e=e/Y-(1==s.ori?si:ti));let n=Qt;1==s.ori&&(n=ei,e=n-e),-1==s.dir&&(e=n-e);let o=s._min,l=o+(s._max-o)*(e/n),r=s.distr;return 3==r?Le(10,l):4==r?ke(l,s.asinh):100==r?s.bwd(l):l}function Mn(e,t){G(En,O,wn.left=e),G(En,S,wn.width=t)}function kn(e,t){G(En,A,wn.top=e),G(En,x,wn.height=t)}bt&&Wi&&Ut(F,St,(e=>{zi._lock||(Yi(e),null!=Ln&&An(null,In,!0,io.setSeries))})),I.valToIdx=e=>re(e,t[0]),I.posToIdx=function(e,i){return re(Dn(e,He,i),t[0],os,ls)},I.posToVal=Dn,I.valToPos=(e,t,i)=>0==Fe[t].ori?H(e,Fe[t],i?vi:Qt,i?ai:0):B(e,Fe[t],i?yi:ei,i?_i:0),I.setCursor=(e,t,i)=>{an=e.left,un=e.top,Un(null,t,i)};let Cn=0==Ze.ori?Mn:kn,Rn=1==Ze.ori?Mn:kn;function Fn(e,t){if(null!=e&&(e.idxs?e.idxs.forEach(((e,t)=>{vt[t]=e})):st(e.idx)||vt.fill(e.idx),yt.idx=vt[0]),bt&&yt.live){for(let e=0;e0||1==U&&!Mt)&&Pn(e,vt[e]);!function(){if(bt&&yt.live)for(let e=2==U?1:0;els;Tn=Re,On=null;let l=0==Ze.ori?Qt:ei,r=1==Ze.ori?Qt:ei;if(an<0||0==ns||o){n=zi.idx=null;for(let e=0;e0&&e.show){let t=null==v?-10:at(v,1==U?Fe[e.scale]:Fe[e.facets[1].scale],r,0);if(Wi&&null!=v){let i=1==Ze.ori?an:un,s=Ee(Vi.dist(I,p,_,t,i));if(s=0?1:-1;o==(v>=0?1:-1)&&(1==o?1==t?v>=n:v<=n:1==t?v<=n:v>=n)&&(Tn=s,On=p)}else Tn=s,On=p}}if(Ui||Gi){let e,i;0==Ze.ori?(e=y,i=t):(e=t,i=y);let s,n,l,r,g,m,_=!0,v=Bi.bbox;if(null!=v){_=!1;let e=v(I,p);l=e.left,r=e.top,s=e.width,n=e.height}else l=e,r=i,s=n=Bi.size(I,p);if(m=Bi.fill(I,p),g=Bi.stroke(I,p),Gi)p==On&&Tn<=Vi.prox&&(o=l,a=r,u=s,c=n,d=_,h=m,f=g);else{let e=Ki[p];null!=e&&(qi[p]=l,Zi[p]=r,ie(e,s,n,_),ee(e,m,g),J(e,Ae(l),Ae(r),Qt,ei))}}}}if(Gi){let e=Vi.prox;if(Ui||(null==Ln?Tn<=e:Tn>e||On!=Ln)){let e=Ki[0];qi[0]=o,Zi[0]=a,ie(e,u,c,d),ee(e,h,f),J(e,Ae(o),Ae(a),Qt,ei)}}}if(wn.show&&_n)if(null!=e){let[t,i]=io.scales,[s,n]=io.match,[o,a]=e.cursor.sync.scales,u=e.cursor.drag;if(yn=u._x,bn=u._y,yn||bn){let u,c,d,h,f,{left:p,top:g,width:m,height:_}=e.select,v=e.scales[o].ori,y=e.posToVal,b=null!=t&&s(t,o),w=null!=i&&n(i,a);b&&yn?(0==v?(u=p,c=m):(u=g,c=_),d=Fe[t],h=rt(y(u,o),d,l,0),f=rt(y(u+c,o),d,l,0),Cn(Te(h,f),Ee(f-h))):Cn(0,l),w&&bn?(1==v?(u=p,c=m):(u=g,c=_),d=Fe[i],h=at(y(u,a),d,r,0),f=at(y(u+c,a),d,r,0),Rn(Te(h,f),Ee(f-h))):Rn(0,r)}else Hn()}else{let e=Ee(ln-tn),t=Ee(rn-sn);if(1==Ze.ori){let i=e;e=t,t=i}yn=vn.x&&e>=vn.dist,bn=vn.y&&t>=vn.dist;let i,s,n=vn.uni;null!=n?yn&&bn&&(yn=e>=n,bn=t>=n,yn||bn||(t>e?bn=!0:yn=!0)):vn.x&&vn.y&&(yn||bn)&&(yn=bn=!0),yn&&(0==Ze.ori?(i=nn,s=an):(i=on,s=un),Cn(Te(i,s),Ee(s-i)),bn||Rn(0,r)),bn&&(1==Ze.ori?(i=nn,s=an):(i=on,s=un),Rn(Te(i,s),Ee(s-i)),yn||Cn(0,l)),yn||bn||(Cn(0,0),Rn(0,0))}if(vn._x=yn,vn._y=bn,null==e){if(s){if(null!=so){let[e,t]=io.scales;io.values[0]=null!=e?Dn(0==Ze.ori?an:un,e):null,io.values[1]=null!=t?Dn(1==Ze.ori?an:un,t):null}oo(M,I,an,un,Qt,ei,n)}if(Wi){let e=s&&io.setSeries,t=Vi.prox;null==Ln?Tn<=t&&An(On,In,!0,e):Tn>t?An(null,In,!0,e):On!=Ln&&An(On,In,!0,e)}}Ui&&(yt.idx=n,Fn()),!1!==i&&eo("setCursor")}I.setLegend=Fn;let Nn=null;function $n(e=!1){e?Nn=null:(Nn=pe.getBoundingClientRect(),eo("syncRect",Nn))}function jn(e,t,i,s,n,o,l){zi._lock||_n&&null!=e&&0==e.movementX&&0==e.movementY||(Xn(e,t,i,s,n,o,l,!1,null!=e),null!=e?Un(null,!0,!0):Un(t,!0,!1))}function Xn(e,t,i,s,n,o,l,r,a){if(null==Nn&&$n(!1),Yi(e),null!=e)i=e.clientX-Nn.left,s=e.clientY-Nn.top;else{if(i<0||s<0)return an=-10,void(un=-10);let[e,l]=io.scales,r=t.cursor.sync,[a,u]=r.values,[c,d]=r.scales,[h,f]=io.match,p=t.axes[0].side%2==1,g=0==Ze.ori?Qt:ei,m=1==Ze.ori?Qt:ei,_=p?o:n,v=p?n:o,y=p?s:i,b=p?i:s;if(i=null!=c?h(e,c)?Z(a,Fe[e],g,0):-10:g*(y/_),s=null!=d?f(l,d)?Z(u,Fe[l],m,0):-10:m*(b/v),1==Ze.ori){let e=i;i=s,s=e}}a&&((i<=1||i>=Qt-1)&&(i=Be(i,Qt)),(s<=1||s>=ei-1)&&(s=Be(s,ei))),r?(tn=i,sn=s,[nn,on]=zi.move(I,i,s)):(an=i,un=s)}Object.defineProperty(I,"rect",{get:()=>(null==Nn&&$n(!1),Nn)});const zn={width:0,height:0,left:0,top:0};function Hn(){Sn(zn,!1)}let Yn,Bn,Vn,Wn;function Gn(e,t,i,s,n,o,l){_n=!0,yn=bn=vn._x=vn._y=!1,Xn(e,t,i,s,n,o,0,!0,!1),null!=e&&(Ut(C,X,Kn,!1),oo(k,I,nn,on,Qt,ei,null));let{left:r,top:a,width:u,height:c}=wn;Yn=r,Bn=a,Vn=u,Wn=c,Hn()}function Kn(e,t,i,s,n,o,l){_n=vn._x=vn._y=!1,Xn(e,t,i,s,n,o,0,!1,!0);let{left:r,top:a,width:u,height:c}=wn,d=u>0||c>0,h=Yn!=r||Bn!=a||Vn!=u||Wn!=c;if(d&&h&&Sn(wn),vn.setScale&&d&&h){let e=r,t=u,i=a,s=c;if(1==Ze.ori&&(e=a,t=c,i=r,s=u),yn&&xn(He,Dn(e,He),Dn(e+t,He)),bn)for(let n in Fe){let e=Fe[n];n!=He&&null==e.from&&e.min!=Re&&xn(n,Dn(i+s,n),Dn(i,n))}Hn()}else zi.lock&&(zi._lock=!zi._lock,Un(null,!0,!1));null!=e&&(Nt(C,X),oo(C,I,an,un,Qt,ei,null))}function qn(e,t,i,s,n,o,l){zi._lock||(Yi(e),Ps(),Hn(),null!=e&&oo(P,I,an,un,Qt,ei,null))}function Zn(){Me.forEach(Ss),Ni(I.width,I.height,!0)}oe(N,z,Zn);const Jn={};Jn.mousedown=Gn,Jn.mousemove=jn,Jn.mouseup=Kn,Jn.dblclick=qn,Jn.setSeries=(e,t,i,s)=>{-1!=(i=(0,io.match[2])(I,t,i))&&An(i,s,!0,!1)},zi.show&&(Ut(k,pe,Gn),Ut(M,pe,jn),Ut(R,pe,(e=>{Yi(e),$n(!1)})),Ut(F,pe,(function(e,t,i,s,n,o,l){if(zi._lock)return;Yi(e);let r=_n;if(_n){let e,t,i=!0,s=!0,n=10;0==Ze.ori?(e=yn,t=bn):(e=bn,t=yn),e&&t&&(i=an<=n||an>=Qt-n,s=un<=n||un>=ei-n),e&&i&&(an=an{e.call(null,I,t,i)}))}(e.plugins||[]).forEach((e=>{for(let t in e.hooks)Qn[t]=(Qn[t]||[]).concat(e.hooks[t])}));const to=(e,t,i)=>i,io=ct({key:null,setSeries:!1,filters:{pub:Xe,sub:Xe},scales:[He,be[1]?be[1].scale:null],match:[ze,ze,to],values:[null,null]},zi.sync);2==io.match.length&&io.match.push(to),zi.sync=io;const so=io.key,no=Ri(so);function oo(e,t,i,s,n,o,l){io.filters.pub(e,t,i,s,n,o,l)&&no.pub(e,t,i,s,n,o,l)}function lo(){eo("init",e,t),Fs(t||e.data,!1),dt[He]?mn(He,dt[He]):Ps(),Ci=wn.show&&(wn.width>0||wn.height>0),Oi=Ui=!0,Ni(e.width,e.height)}return no.sub(I),I.pub=function(e,t,i,s,n,o,l){io.filters.sub(e,t,i,s,n,o,l)&&Jn[e](null,t,i,s,n,o,l)},I.destroy=function(){no.unsub(I),as.delete(I),Pt.clear(),le(N,z,Zn),te.remove(),St?.remove(),eo("destroy")},be.forEach(Qi),Me.forEach((function(e,t){if(e._show=e.show,e.show){let i=e.side%2,s=Fe[e.scale];null==s&&(e.scale=i?be[1].scale:He,s=Fe[e.scale]);let n=s.time;e.size=Ue(e.size),e.space=Ue(e.space),e.rotate=Ue(e.rotate),tt(e.incrs)&&e.incrs.forEach((e=>{!Ke.has(e)&&Ke.set(e,qe(e))})),e.incrs=Ue(e.incrs||(2==s.distr?Ot:n?1==ye?jt:Ht:Lt)),e.splits=Ue(e.splits||(n&&1==s.distr?gt:3==s.distr?gi:4==s.distr?mi:pi)),e.stroke=Ue(e.stroke),e.grid.stroke=Ue(e.grid.stroke),e.ticks.stroke=Ue(e.ticks.stroke),e.border.stroke=Ue(e.border.stroke);let o=e.values;e.values=tt(o)&&!tt(o[0])?Ue(o):n?tt(o)?Wt(ft,Vt(o,pt)):nt(o)?function(e,t){let i=wt(t);return(t,s,n,o,l)=>s.map((t=>i(e(t))))}(ft,o):o||mt:o||fi,e.filter=Ue(e.filter||(s.distr>=3&&10==s.log?Ei:3==s.distr&&2==s.log?Si:$e)),e.font=Es(e.font),e.labelFont=Es(e.labelFont),e._size=e.size(I,null,t,0),e._space=e._rotate=e._incrs=e._found=e._splits=e._values=null,e._size>0&&(es[t]=!0,e._el=q(c,ae))}})),i?i instanceof HTMLElement?(i.appendChild(te),lo()):i(I,lo):lo(),I}xs.assign=ct,xs.fmtNum=ye,xs.rangeNum=ge,xs.rangeLog=ue,xs.rangeAsinh=ce,xs.orient=Ui,xs.pxRatio=Y,xs.join=function(e,t){if(function(e){let t=e[0][0],i=t.length;for(let s=1;s=s&&null==e[n];)n--;if(n<=s)return!0;const o=Oe(1,Se((n-s+1)/t));for(let l=e[s],r=s+o;r<=n;r+=o){const t=e[r];if(null!=t){if(t<=l)return!1;l=t}}return!0}(t[0])||(t=function(e){let t=e[0],i=t.length,s=Array(i);for(let o=0;ot[e]-t[i]));let n=[];for(let o=0;oe-t))],n=s[0].length,o=new Map;for(let l=0;lUi(e,o,((a,u,c,d,h,f,p,g,m,_,v)=>{let y=a.pxRound,{left:b,width:w}=e.bbox,E=e=>y(f(e,d,_,g)),S=e=>y(p(e,h,v,m)),x=0==d.ori?Wi:Gi;const A={stroke:new Path2D,fill:null,clip:null,band:null,gaps:null,flags:Fi},T=A.stroke,O=d.dir*(0==d.ori?1:-1);l=ae(c,l,r,1),r=ae(c,l,r,-1);let L=S(c[1==O?l:r]),I=E(u[1==O?l:r]),D=I,M=I;n&&-1==t&&(M=b,x(T,M,L)),x(T,I,L);for(let e=1==O?l:r;e>=l&&e<=r;e+=O){let i=c[e];if(null==i)continue;let s=E(u[e]),n=S(i);1==t?x(T,s,L):x(T,D,n),x(T,s,n),L=n,D=s}let k=D;n&&1==t&&(k=b+w,x(T,k,L));let[C,R]=Ni(e,o);if(null!=a.fill||0!=C){let t=A.fill=new Path2D(T),i=S(a.fillTo(e,o,a.min,a.max,C));x(t,k,i),x(t,M,i)}if(!a.spanGaps){let n=[];n.push(...zi(u,c,l,r,O,E,s));let h=a.width*Y/2,f=i||1==t?h:-h,p=i||-1==t?-h:h;n.forEach((e=>{e[0]+=f,e[1]+=p})),A.gaps=n=a.gaps(e,o,l,r,n),A.clip=Xi(n,d.ori,g,m,_,v)}return 0!=R&&(A.band=2==R?[ji(e,o,l,r,T,-1),ji(e,o,l,r,T,1)]:ji(e,o,l,r,T,R)),A}))},e.bars=function(e){const t=me((e=e||Je).size,[.6,Re,1]),i=e.align||0,s=e.gap||0;let n=e.radius;n=null==n?[0,0]:"number"==typeof n?[n,0]:n;const o=Ue(n),l=1-t[0],r=me(t[1],Re),a=me(t[2],1),u=me(e.disp,Je),c=me(e.each,(e=>{})),{fill:d,stroke:h}=u;return(e,t,n,f)=>Ui(e,t,((p,g,m,_,v,y,b,w,E,S,x)=>{let A,T,O=p.pxRound,L=i,I=s*Y,D=r*Y,M=a*Y;0==_.ori?[A,T]=o(e,t):[T,A]=o(e,t);const k=_.dir*(0==_.ori?1:-1);let C,R,F,P=0==_.ori?Ki:qi,U=0==_.ori?c:(e,t,i,s,n,o,l)=>{c(e,t,i,n,s,l,o)},N=me(e.bands,Qe).find((e=>e.series[0]==t)),$=null!=N?N.dir:0,j=p.fillTo(e,t,p.min,p.max,$),X=O(b(j,v,x,E)),z=S,H=O(p.width*Y),B=!1,V=null,W=null,G=null,K=null;null==d||0!=H&&null==h||(B=!0,V=d.values(e,t,n,f),W=new Map,new Set(V).forEach((e=>{null!=e&&W.set(e,new Path2D)})),H>0&&(G=h.values(e,t,n,f),K=new Map,new Set(G).forEach((e=>{null!=e&&K.set(e,new Path2D)}))));let{x0:q,size:Z}=u;if(null!=q&&null!=Z){L=1,g=q.values(e,t,n,f),2==q.unit&&(g=g.map((t=>e.posToVal(w+t*S,_.key,!0))));let i=Z.values(e,t,n,f);R=2==Z.unit?i[0]*S:y(i[0],_,S,w)-y(0,_,S,w),z=ls(g,m,y,_,S,w,z),F=z-R+I}else z=ls(g,m,y,_,S,w,z),F=z*l+I,R=z-F;F<1&&(F=0),H>=R/2&&(H=0),F<5&&(O=Ne);let J=F>0;R=O(Pe(z-F-(J?H:0),M,D)),C=(0==L?R/2:L==k?0:R)-L*k*((0==L?I/2:0)+(J?H/2:0));const Q={stroke:null,fill:null,clip:null,band:null,gaps:null,flags:0},ee=B?null:new Path2D;let te=null;if(null!=N)te=e.data[N.series[1]];else{let{y0:i,y1:s}=u;null!=i&&null!=s&&(m=s.values(e,t,n,f),te=i.values(e,t,n,f))}let ie=A*R,se=T*R;for(let i=1==k?n:f;i>=n&&i<=f;i+=k){let s=m[i];if(null==s)continue;if(null!=te){let e=te[i]??0;if(s-e==0)continue;X=b(e,v,x,E)}let n=y(2!=_.distr||null!=u?g[i]:i,_,S,w),o=b(me(s,j),v,x,E),l=O(n-C),r=O(Oe(o,X)),a=O(Te(o,X)),c=r-a;if(null!=s){let n=s<0?se:ie,o=s<0?ie:se;B?(H>0&&null!=G[i]&&P(K.get(G[i]),l,a+Se(H/2),R,Oe(0,c-H),n,o),null!=V[i]&&P(W.get(V[i]),l,a+Se(H/2),R,Oe(0,c-H),n,o)):P(ee,l,a+Se(H/2),R,Oe(0,c-H),n,o),U(e,t,i,l-H/2,a,R+H,c)}}return H>0?Q.stroke=B?K:ee:B||(Q._fill=0==p.width?p._fill:p._stroke??p._fill,Q.width=0),Q.fill=B?W:ee,Q}))},e.spline=function(e){return function(e,t){const i=me(t?.alignGaps,0);return(t,s,n,o)=>Ui(t,s,((l,r,a,u,c,d,h,f,p,g,m)=>{let _,v,y,b=l.pxRound,w=e=>b(d(e,u,g,f)),E=e=>b(h(e,c,m,p));0==u.ori?(_=Bi,y=Wi,v=Qi):(_=Vi,y=Gi,v=es);const S=u.dir*(0==u.ori?1:-1);n=ae(a,n,o,1),o=ae(a,n,o,-1);let x=w(r[1==S?n:o]),A=x,T=[],O=[];for(let e=1==S?n:o;e>=n&&e<=o;e+=S)if(null!=a[e]){let t=w(r[e]);T.push(A=t),O.push(E(a[e]))}const L={stroke:e(T,O,_,y,v,b),fill:null,clip:null,band:null,gaps:null,flags:Fi},I=L.stroke;let[D,M]=Ni(t,s);if(null!=l.fill||0!=D){let e=L.fill=new Path2D(I),i=E(l.fillTo(t,s,l.min,l.max,D));y(e,A,i),y(e,x,i)}if(!l.spanGaps){let e=[];e.push(...zi(r,a,n,o,S,w,i)),L.gaps=e=l.gaps(t,s,n,o,e),L.clip=Xi(e,u.ori,f,p,g,m)}return 0!=M&&(L.band=2==M?[ji(t,s,n,o,I,-1),ji(t,s,n,o,I,1)]:ji(t,s,n,o,I,M)),L}))}(rs,e)}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1865.72c933c8.chunk.js b/ydb/core/viewer/monitoring/static/js/1865.72c933c8.chunk.js deleted file mode 100644 index cb566c9db9a8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1865.72c933c8.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1865],{61865:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ka",weekdays:"\u10d9\u10d5\u10d8\u10e0\u10d0_\u10dd\u10e0\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10e1\u10d0\u10db\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10dd\u10d7\u10ee\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10ee\u10e3\u10d7\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10de\u10d0\u10e0\u10d0\u10e1\u10d9\u10d4\u10d5\u10d8_\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8".split("_"),weekdaysShort:"\u10d9\u10d5\u10d8_\u10dd\u10e0\u10e8_\u10e1\u10d0\u10db_\u10dd\u10d7\u10ee_\u10ee\u10e3\u10d7_\u10de\u10d0\u10e0_\u10e8\u10d0\u10d1".split("_"),weekdaysMin:"\u10d9\u10d5_\u10dd\u10e0_\u10e1\u10d0_\u10dd\u10d7_\u10ee\u10e3_\u10de\u10d0_\u10e8\u10d0".split("_"),months:"\u10d8\u10d0\u10dc\u10d5\u10d0\u10e0\u10d8_\u10d7\u10d4\u10d1\u10d4\u10e0\u10d5\u10d0\u10da\u10d8_\u10db\u10d0\u10e0\u10e2\u10d8_\u10d0\u10de\u10e0\u10d8\u10da\u10d8_\u10db\u10d0\u10d8\u10e1\u10d8_\u10d8\u10d5\u10dc\u10d8\u10e1\u10d8_\u10d8\u10d5\u10da\u10d8\u10e1\u10d8_\u10d0\u10d2\u10d5\u10d8\u10e1\u10e2\u10dd_\u10e1\u10d4\u10e5\u10e2\u10d4\u10db\u10d1\u10d4\u10e0\u10d8_\u10dd\u10e5\u10e2\u10dd\u10db\u10d1\u10d4\u10e0\u10d8_\u10dc\u10dd\u10d4\u10db\u10d1\u10d4\u10e0\u10d8_\u10d3\u10d4\u10d9\u10d4\u10db\u10d1\u10d4\u10e0\u10d8".split("_"),monthsShort:"\u10d8\u10d0\u10dc_\u10d7\u10d4\u10d1_\u10db\u10d0\u10e0_\u10d0\u10de\u10e0_\u10db\u10d0\u10d8_\u10d8\u10d5\u10dc_\u10d8\u10d5\u10da_\u10d0\u10d2\u10d5_\u10e1\u10d4\u10e5_\u10dd\u10e5\u10e2_\u10dc\u10dd\u10d4_\u10d3\u10d4\u10d9".split("_"),weekStart:1,formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"%s \u10e8\u10d4\u10db\u10d3\u10d4\u10d2",past:"%s \u10ec\u10d8\u10dc",s:"\u10ec\u10d0\u10db\u10d8",m:"\u10ec\u10e3\u10d7\u10d8",mm:"%d \u10ec\u10e3\u10d7\u10d8",h:"\u10e1\u10d0\u10d0\u10d7\u10d8",hh:"%d \u10e1\u10d0\u10d0\u10d7\u10d8\u10e1",d:"\u10d3\u10e6\u10d4\u10e1",dd:"%d \u10d3\u10e6\u10d8\u10e1 \u10d2\u10d0\u10dc\u10db\u10d0\u10d5\u10da\u10dd\u10d1\u10d0\u10e8\u10d8",M:"\u10d7\u10d5\u10d8\u10e1",MM:"%d \u10d7\u10d5\u10d8\u10e1",y:"\u10ec\u10d4\u10da\u10d8",yy:"%d \u10ec\u10da\u10d8\u10e1"},ordinal:function(_){return _}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/19026.f05aa9b2.chunk.js b/ydb/core/viewer/monitoring/static/js/19026.f05aa9b2.chunk.js new file mode 100644 index 000000000000..ea95f90ddd41 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/19026.f05aa9b2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[19026],{19026:(e,t,a)=>{a.d(t,{default:()=>s});var r=a(64723);const s=a.n(r)()},64723:e=>{function t(e){e.languages["splunk-spl"]={comment:/`comment\("(?:\\.|[^\\"])*"\)`/,string:{pattern:/"(?:\\.|[^\\"])*"/,greedy:!0},keyword:/\b(?:abstract|accum|addcoltotals|addinfo|addtotals|analyzefields|anomalies|anomalousvalue|anomalydetection|append|appendcols|appendcsv|appendlookup|appendpipe|arules|associate|audit|autoregress|bin|bucket|bucketdir|chart|cluster|cofilter|collect|concurrency|contingency|convert|correlate|datamodel|dbinspect|dedup|delete|delta|diff|erex|eval|eventcount|eventstats|extract|fieldformat|fields|fieldsummary|filldown|fillnull|findtypes|folderize|foreach|format|from|gauge|gentimes|geom|geomfilter|geostats|head|highlight|history|iconify|input|inputcsv|inputlookup|iplocation|join|kmeans|kv|kvform|loadjob|localize|localop|lookup|makecontinuous|makemv|makeresults|map|mcollect|metadata|metasearch|meventcollect|mstats|multikv|multisearch|mvcombine|mvexpand|nomv|outlier|outputcsv|outputlookup|outputtext|overlap|pivot|predict|rangemap|rare|regex|relevancy|reltime|rename|replace|rest|return|reverse|rex|rtorder|run|savedsearch|script|scrub|search|searchtxn|selfjoin|sendemail|set|setfields|sichart|sirare|sistats|sitimechart|sitop|sort|spath|stats|strcat|streamstats|table|tags|tail|timechart|timewrap|top|transaction|transpose|trendline|tscollect|tstats|typeahead|typelearner|typer|union|uniq|untable|where|x11|xmlkv|xmlunescape|xpath|xyseries)\b/i,"operator-word":{pattern:/\b(?:and|as|by|not|or|xor)\b/i,alias:"operator"},function:/\b\w+(?=\s*\()/,property:/\b\w+(?=\s*=(?!=))/,date:{pattern:/\b\d{1,2}\/\d{1,2}\/\d{1,4}(?:(?::\d{1,2}){3})?\b/,alias:"number"},number:/\b\d+(?:\.\d+)?\b/,boolean:/\b(?:f|false|t|true)\b/i,operator:/[<>=]=?|[-+*/%|]/,punctuation:/[()[\],]/}}e.exports=t,t.displayName="splunkSpl",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/1917.e3ac9c6d.chunk.js b/ydb/core/viewer/monitoring/static/js/1917.e3ac9c6d.chunk.js deleted file mode 100644 index a4519a5e1b4e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1917.e3ac9c6d.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1917],{61917:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"hy-am",weekdays:"\u056f\u056b\u0580\u0561\u056f\u056b_\u0565\u0580\u056f\u0578\u0582\u0577\u0561\u0562\u0569\u056b_\u0565\u0580\u0565\u0584\u0577\u0561\u0562\u0569\u056b_\u0579\u0578\u0580\u0565\u0584\u0577\u0561\u0562\u0569\u056b_\u0570\u056b\u0576\u0563\u0577\u0561\u0562\u0569\u056b_\u0578\u0582\u0580\u0562\u0561\u0569_\u0577\u0561\u0562\u0561\u0569".split("_"),months:"\u0570\u0578\u0582\u0576\u057e\u0561\u0580\u056b_\u0583\u0565\u057f\u0580\u057e\u0561\u0580\u056b_\u0574\u0561\u0580\u057f\u056b_\u0561\u057a\u0580\u056b\u056c\u056b_\u0574\u0561\u0575\u056b\u057d\u056b_\u0570\u0578\u0582\u0576\u056b\u057d\u056b_\u0570\u0578\u0582\u056c\u056b\u057d\u056b_\u0585\u0563\u0578\u057d\u057f\u0578\u057d\u056b_\u057d\u0565\u057a\u057f\u0565\u0574\u0562\u0565\u0580\u056b_\u0570\u0578\u056f\u057f\u0565\u0574\u0562\u0565\u0580\u056b_\u0576\u0578\u0575\u0565\u0574\u0562\u0565\u0580\u056b_\u0564\u0565\u056f\u057f\u0565\u0574\u0562\u0565\u0580\u056b".split("_"),weekStart:1,weekdaysShort:"\u056f\u0580\u056f_\u0565\u0580\u056f_\u0565\u0580\u0584_\u0579\u0580\u0584_\u0570\u0576\u0563_\u0578\u0582\u0580\u0562_\u0577\u0562\u0569".split("_"),monthsShort:"\u0570\u0576\u057e_\u0583\u057f\u0580_\u0574\u0580\u057f_\u0561\u057a\u0580_\u0574\u0575\u057d_\u0570\u0576\u057d_\u0570\u056c\u057d_\u0585\u0563\u057d_\u057d\u057a\u057f_\u0570\u056f\u057f_\u0576\u0574\u0562_\u0564\u056f\u057f".split("_"),weekdaysMin:"\u056f\u0580\u056f_\u0565\u0580\u056f_\u0565\u0580\u0584_\u0579\u0580\u0584_\u0570\u0576\u0563_\u0578\u0582\u0580\u0562_\u0577\u0562\u0569".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY \u0569.",LLL:"D MMMM YYYY \u0569., HH:mm",LLLL:"dddd, D MMMM YYYY \u0569., HH:mm"},relativeTime:{future:"%s \u0570\u0565\u057f\u0578",past:"%s \u0561\u057c\u0561\u057b",s:"\u0574\u056b \u0584\u0561\u0576\u056b \u057e\u0561\u0575\u0580\u056f\u0575\u0561\u0576",m:"\u0580\u0578\u057a\u0565",mm:"%d \u0580\u0578\u057a\u0565",h:"\u056a\u0561\u0574",hh:"%d \u056a\u0561\u0574",d:"\u0585\u0580",dd:"%d \u0585\u0580",M:"\u0561\u0574\u056b\u057d",MM:"%d \u0561\u0574\u056b\u057d",y:"\u057f\u0561\u0580\u056b",yy:"%d \u057f\u0561\u0580\u056b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/19233.b4069ac2.chunk.js b/ydb/core/viewer/monitoring/static/js/19233.b4069ac2.chunk.js new file mode 100644 index 000000000000..157953e96d15 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/19233.b4069ac2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[19233],{19233:(a,e,l)=>{l.d(e,{default:()=>t});var n=l(85146);const t=l.n(n)()},85146:a=>{function e(a){a.languages.wolfram={comment:/\(\*(?:\(\*(?:[^*]|\*(?!\)))*\*\)|(?!\(\*)[\s\S])*?\*\)/,string:{pattern:/"(?:\\.|[^"\\\r\n])*"/,greedy:!0},keyword:/\b(?:Abs|AbsArg|Accuracy|Block|Do|For|Function|If|Manipulate|Module|Nest|NestList|None|Return|Switch|Table|Which|While)\b/,context:{pattern:/\b\w+`+\w*/,alias:"class-name"},blank:{pattern:/\b\w+_\b/,alias:"regex"},"global-variable":{pattern:/\$\w+/,alias:"variable"},boolean:/\b(?:False|True)\b/,number:/(?:\b(?=\d)|\B(?=\.))(?:0[bo])?(?:(?:\d|0x[\da-f])[\da-f]*(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?j?\b/i,operator:/\/\.|;|=\.|\^=|\^:=|:=|<<|>>|<\||\|>|:>|\|->|->|<-|@@@|@@|@|\/@|=!=|===|==|=|\+|-|\^|\[\/-+%=\]=?|!=|\*\*?=?|\/\/?=?|<[<=>]?|>[=>]?|[&|^~]/,punctuation:/[{}[\];(),.:]/},a.languages.mathematica=a.languages.wolfram,a.languages.wl=a.languages.wolfram,a.languages.nb=a.languages.wolfram}a.exports=e,e.displayName="wolfram",e.aliases=["mathematica","wl","nb"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/19507.0512979b.chunk.js b/ydb/core/viewer/monitoring/static/js/19507.0512979b.chunk.js new file mode 100644 index 000000000000..27ab0301fa4b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/19507.0512979b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[19507],{19507:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>o,getLanguage:()=>i});var s=t(43733);const o={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"`",close:"`",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],wordPattern:/(-?\d*\.\d\w*)|([^`~!@#%^&*()\-=+[{\]}\\|;:'",./?\s]+)/g};function i({ansi:e=!1}={}){return{defaultToken:"text",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"}],keywords:s.RE,typeKeywords:s.to,constants:["true","false","enabled","disabled"],builtinFunctions:s.XB,operators:["+","-","/","//","%","<@>","@>","<@","&","^","~","<",">","<=",">=","=>","==","!=","<>","="],symbols:/[=>{n.d(t,{default:()=>i});var r=n(66651);const i=n.n(r)()},66651:e=>{function t(e){e.languages.nsis={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|[#;].*)/,lookbehind:!0,greedy:!0},string:{pattern:/("|')(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0},keyword:{pattern:/(^[\t ]*)(?:Abort|Add(?:BrandingImage|Size)|AdvSplash|Allow(?:RootDirInstall|SkipFiles)|AutoCloseWindow|BG(?:Font|Gradient|Image)|Banner|BrandingText|BringToFront|CRCCheck|Call(?:InstDLL)?|Caption|ChangeUI|CheckBitmap|ClearErrors|CompletedText|ComponentText|CopyFiles|Create(?:Directory|Font|ShortCut)|Delete(?:INISec|INIStr|RegKey|RegValue)?|Detail(?:Print|sButtonText)|Dialer|Dir(?:Text|Var|Verify)|EnableWindow|Enum(?:RegKey|RegValue)|Exch|Exec(?:Shell(?:Wait)?|Wait)?|ExpandEnvStrings|File(?:BufSize|Close|ErrorText|Open|Read|ReadByte|ReadUTF16LE|ReadWord|Seek|Write|WriteByte|WriteUTF16LE|WriteWord)?|Find(?:Close|First|Next|Window)|FlushINI|Get(?:CurInstType|CurrentAddress|DLLVersion(?:Local)?|DlgItem|ErrorLevel|FileTime(?:Local)?|FullPathName|Function(?:Address|End)?|InstDirError|LabelAddress|TempFileName)|Goto|HideWindow|Icon|If(?:Abort|Errors|FileExists|RebootFlag|Silent)|InitPluginsDir|InstProgressFlags|Inst(?:Type(?:GetText|SetText)?)|Install(?:ButtonText|Colors|Dir(?:RegKey)?)|Int(?:64|Ptr)?CmpU?|Int(?:64)?Fmt|Int(?:Ptr)?Op|IsWindow|Lang(?:DLL|String)|License(?:BkColor|Data|ForceSelection|LangString|Text)|LoadLanguageFile|LockWindow|Log(?:Set|Text)|Manifest(?:DPIAware|SupportedOS)|Math|MessageBox|MiscButtonText|NSISdl|Name|Nop|OutFile|PE(?:DllCharacteristics|SubsysVer)|Page(?:Callbacks)?|Pop|Push|Quit|RMDir|Read(?:EnvStr|INIStr|RegDWORD|RegStr)|Reboot|RegDLL|Rename|RequestExecutionLevel|ReserveFile|Return|SearchPath|Section(?:End|GetFlags|GetInstTypes|GetSize|GetText|Group|In|SetFlags|SetInstTypes|SetSize|SetText)?|SendMessage|Set(?:AutoClose|BrandingImage|Compress|Compressor(?:DictSize)?|CtlColors|CurInstType|DatablockOptimize|DateSave|Details(?:Print|View)|ErrorLevel|Errors|FileAttributes|Font|OutPath|Overwrite|PluginUnload|RebootFlag|RegView|ShellVarContext|Silent)|Show(?:InstDetails|UninstDetails|Window)|Silent(?:Install|UnInstall)|Sleep|SpaceTexts|Splash|StartMenu|Str(?:CmpS?|Cpy|Len)|SubCaption|System|UnRegDLL|Unicode|UninstPage|Uninstall(?:ButtonText|Caption|Icon|SubCaption|Text)|UserInfo|VI(?:AddVersionKey|FileVersion|ProductVersion)|VPatch|Var|WindowIcon|Write(?:INIStr|Reg(?:Bin|DWORD|ExpandStr|MultiStr|None|Str)|Uninstaller)|XPStyle|ns(?:Dialogs|Exec))\b/m,lookbehind:!0},property:/\b(?:ARCHIVE|FILE_(?:ATTRIBUTE_ARCHIVE|ATTRIBUTE_NORMAL|ATTRIBUTE_OFFLINE|ATTRIBUTE_READONLY|ATTRIBUTE_SYSTEM|ATTRIBUTE_TEMPORARY)|HK(?:(?:CR|CU|LM)(?:32|64)?|DD|PD|U)|HKEY_(?:CLASSES_ROOT|CURRENT_CONFIG|CURRENT_USER|DYN_DATA|LOCAL_MACHINE|PERFORMANCE_DATA|USERS)|ID(?:ABORT|CANCEL|IGNORE|NO|OK|RETRY|YES)|MB_(?:ABORTRETRYIGNORE|DEFBUTTON1|DEFBUTTON2|DEFBUTTON3|DEFBUTTON4|ICONEXCLAMATION|ICONINFORMATION|ICONQUESTION|ICONSTOP|OK|OKCANCEL|RETRYCANCEL|RIGHT|RTLREADING|SETFOREGROUND|TOPMOST|USERICON|YESNO)|NORMAL|OFFLINE|READONLY|SHCTX|SHELL_CONTEXT|SYSTEM|TEMPORARY|admin|all|auto|both|colored|false|force|hide|highest|lastused|leave|listonly|none|normal|notset|off|on|open|print|show|silent|silentlog|smooth|textonly|true|user)\b/,constant:/\$\{[!\w\.:\^-]+\}|\$\([!\w\.:\^-]+\)/,variable:/\$\w[\w\.]*/,number:/\b0x[\dA-Fa-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee]-?\d+)?/,operator:/--?|\+\+?|<=?|>=?|==?=?|&&?|\|\|?|[?*\/~^%]/,punctuation:/[{}[\];(),.:]/,important:{pattern:/(^[\t ]*)!(?:addincludedir|addplugindir|appendfile|cd|define|delfile|echo|else|endif|error|execute|finalize|getdllversion|gettlbversion|if|ifdef|ifmacrodef|ifmacrondef|ifndef|include|insertmacro|macro|macroend|makensis|packhdr|pragma|searchparse|searchreplace|system|tempfile|undef|verbose|warning)\b/im,lookbehind:!0}}}e.exports=t,t.displayName="nsis",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/19728.daf9b9f8.chunk.js b/ydb/core/viewer/monitoring/static/js/19728.daf9b9f8.chunk.js new file mode 100644 index 000000000000..c82834129f4f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/19728.daf9b9f8.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 19728.daf9b9f8.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[19728],{19728:(e,t,i)=>{i.r(t),i.d(t,{conf:()=>p,language:()=>w});var n,o,r=i(80781),l=Object.defineProperty,a=Object.getOwnPropertyDescriptor,d=Object.getOwnPropertyNames,s=Object.prototype.hasOwnProperty,u=(e,t,i,n)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let o of d(t))s.call(e,o)||o===i||l(e,o,{get:()=>t[o],enumerable:!(n=a(t,o))||n.enumerable});return e},c={};u(c,n=r,"default"),o&&u(o,n,"default");var m=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],p={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,brackets:[["\x3c!--","--\x3e"],["<",">"],["{{","}}"],["{%","%}"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"%",close:"%"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${m.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/(\w[\w\d]*)\s*>$/i,action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${m.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:c.languages.IndentAction.Indent}}]},w={defaultToken:"",tokenPostfix:"",builtinTags:["if","else","elseif","endif","render","assign","capture","endcapture","case","endcase","comment","endcomment","cycle","decrement","for","endfor","include","increment","layout","raw","endraw","render","tablerow","endtablerow","unless","endunless"],builtinFilters:["abs","append","at_least","at_most","capitalize","ceil","compact","date","default","divided_by","downcase","escape","escape_once","first","floor","join","json","last","lstrip","map","minus","modulo","newline_to_br","plus","prepend","remove","remove_first","replace","replace_first","reverse","round","rstrip","size","slice","sort","sort_natural","split","strip","strip_html","strip_newlines","times","truncate","truncatewords","uniq","upcase","url_decode","url_encode","where"],constants:["true","false"],operators:["==","!=",">","<",">=","<="],symbol:/[=>)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)([:\w]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)([\w\-]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[//,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],liquidState:[[/\{\{/,"delimiter.output.liquid"],[/\}\}/,{token:"delimiter.output.liquid",switchTo:"@$S2.$S3"}],[/\{\%/,"delimiter.tag.liquid"],[/raw\s*\%\}/,"delimiter.tag.liquid","@liquidRaw"],[/\%\}/,{token:"delimiter.tag.liquid",switchTo:"@$S2.$S3"}],{include:"liquidRoot"}],liquidRaw:[[/^(?!\{\%\s*endraw\s*\%\}).+/],[/\{\%/,"delimiter.tag.liquid"],[/@identifier/],[/\%\}/,{token:"delimiter.tag.liquid",next:"@root"}]],liquidRoot:[[/\d+(\.\d+)?/,"number.liquid"],[/"[^"]*"/,"string.liquid"],[/'[^']*'/,"string.liquid"],[/\s+/],[/@symbol/,{cases:{"@operators":"operator.liquid","@default":""}}],[/\./],[/@identifier/,{cases:{"@constants":"keyword.liquid","@builtinFilters":"predefined.liquid","@builtinTags":"predefined.liquid","@default":"variable.liquid"}}],[/[^}|%]/,"variable.liquid"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2016.397296b7.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/19728.daf9b9f8.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2016.397296b7.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/19728.daf9b9f8.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/1975.e3066826.chunk.js b/ydb/core/viewer/monitoring/static/js/1975.e3066826.chunk.js deleted file mode 100644 index b6e10b36075b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/1975.e3066826.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1975],{31975:function(e,_,t){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=_(e),a={name:"me",weekdays:"nedjelja_ponedjeljak_utorak_srijeda_\u010detvrtak_petak_subota".split("_"),months:"januar_februar_mart_april_maj_jun_jul_avgust_septembar_oktobar_novembar_decembar".split("_"),weekStart:1,weekdaysShort:"ned._pon._uto._sri._\u010det._pet._sub.".split("_"),monthsShort:"jan._feb._mar._apr._maj_jun_jul_avg._sep._okt._nov._dec.".split("_"),weekdaysMin:"ne_po_ut_sr_\u010de_pe_su".split("_"),ordinal:function(e){return e},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm"}};return t.default.locale(a,null,!0),a}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/19791.feabd3fc.chunk.js b/ydb/core/viewer/monitoring/static/js/19791.feabd3fc.chunk.js new file mode 100644 index 000000000000..6055544e0d5d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/19791.feabd3fc.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[19791],{19791:(e,r,t)=>{t.d(r,{default:()=>a});var n=t(47204);const a=t.n(n)()},47204:e=>{function r(e){!function(e){for(var r=/"(?:\\.|[^\\"\r\n])*"|'(?:\\.|[^\\'\r\n])*'/.source,t=/\/\/.*(?!.)|\/\*(?:[^*]|\*(?!\/))*\*\//.source,n=/(?:[^\\()[\]{}"'/]||\/(?![*/])||\(*\)|\[*\]|\{*\}|\\[\s\S])/.source.replace(//g,(function(){return r})).replace(//g,(function(){return t})),a=0;a<2;a++)n=n.replace(//g,(function(){return n}));n=n.replace(//g,"[^\\s\\S]"),e.languages.qml={comment:{pattern:/\/\/.*|\/\*[\s\S]*?\*\//,greedy:!0},"javascript-function":{pattern:RegExp(/((?:^|;)[ \t]*)function\s+(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*\s*\(*\)\s*\{*\}/.source.replace(//g,(function(){return n})),"m"),lookbehind:!0,greedy:!0,alias:"language-javascript",inside:e.languages.javascript},"class-name":{pattern:/((?:^|[:;])[ \t]*)(?!\d)\w+(?=[ \t]*\{|[ \t]+on\b)/m,lookbehind:!0},property:[{pattern:/((?:^|[;{])[ \t]*)(?!\d)\w+(?:\.\w+)*(?=[ \t]*:)/m,lookbehind:!0},{pattern:/((?:^|[;{])[ \t]*)property[ \t]+(?!\d)\w+(?:\.\w+)*[ \t]+(?!\d)\w+(?:\.\w+)*(?=[ \t]*:)/m,lookbehind:!0,inside:{keyword:/^property/,property:/\w+(?:\.\w+)*/}}],"javascript-expression":{pattern:RegExp(/(:[ \t]*)(?![\s;}[])(?:(?!$|[;}]))+/.source.replace(//g,(function(){return n})),"m"),lookbehind:!0,greedy:!0,alias:"language-javascript",inside:e.languages.javascript},string:{pattern:/"(?:\\.|[^\\"\r\n])*"/,greedy:!0},keyword:/\b(?:as|import|on)\b/,punctuation:/[{}[\]:;,]/}}(e)}e.exports=r,r.displayName="qml",r.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/20053.925f8331.chunk.js b/ydb/core/viewer/monitoring/static/js/20053.925f8331.chunk.js new file mode 100644 index 000000000000..550ef3aa228b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/20053.925f8331.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[20053],{20053:(e,t,a)=>{a.d(t,{default:()=>s});var n=a(74224);const s=a.n(n)()},74224:e=>{function t(e){!function(e){function t(e){return RegExp("(^(?:"+e+"):[ \t]*(?![ \t]))[^]+","i")}e.languages.http={"request-line":{pattern:/^(?:CONNECT|DELETE|GET|HEAD|OPTIONS|PATCH|POST|PRI|PUT|SEARCH|TRACE)\s(?:https?:\/\/|\/)\S*\sHTTP\/[\d.]+/m,inside:{method:{pattern:/^[A-Z]+\b/,alias:"property"},"request-target":{pattern:/^(\s)(?:https?:\/\/|\/)\S*(?=\s)/,lookbehind:!0,alias:"url",inside:e.languages.uri},"http-version":{pattern:/^(\s)HTTP\/[\d.]+/,lookbehind:!0,alias:"property"}}},"response-status":{pattern:/^HTTP\/[\d.]+ \d+ .+/m,inside:{"http-version":{pattern:/^HTTP\/[\d.]+/,alias:"property"},"status-code":{pattern:/^(\s)\d+(?=\s)/,lookbehind:!0,alias:"number"},"reason-phrase":{pattern:/^(\s).+/,lookbehind:!0,alias:"string"}}},header:{pattern:/^[\w-]+:.+(?:(?:\r\n?|\n)[ \t].+)*/m,inside:{"header-value":[{pattern:t(/Content-Security-Policy/.source),lookbehind:!0,alias:["csp","languages-csp"],inside:e.languages.csp},{pattern:t(/Public-Key-Pins(?:-Report-Only)?/.source),lookbehind:!0,alias:["hpkp","languages-hpkp"],inside:e.languages.hpkp},{pattern:t(/Strict-Transport-Security/.source),lookbehind:!0,alias:["hsts","languages-hsts"],inside:e.languages.hsts},{pattern:t(/[^:]+/.source),lookbehind:!0}],"header-name":{pattern:/^[^:]+/,alias:"keyword"},punctuation:/^:/}}};var a,n=e.languages,s={"application/javascript":n.javascript,"application/json":n.json||n.javascript,"application/xml":n.xml,"text/xml":n.xml,"text/html":n.html,"text/css":n.css,"text/plain":n.plain},i={"application/json":!0,"application/xml":!0};function r(e){var t=e.replace(/^[a-z]+\//,"");return"(?:"+e+"|"+("\\w+/(?:[\\w.-]+\\+)+"+t+"(?![+\\w.-])")+")"}for(var p in s)if(s[p]){a=a||{};var o=i[p]?r(p):p;a[p.replace(/\//g,"-")]={pattern:RegExp("("+/content-type:\s*/.source+o+/(?:(?:\r\n?|\n)[\w-].*)*(?:\r(?:\n|(?!\n))|\n)/.source+")"+/[^ \t\w-][\s\S]*/.source,"i"),lookbehind:!0,inside:s[p]}}a&&e.languages.insertBefore("http","header",a)}(e)}e.exports=t,t.displayName="http",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2016.397296b7.chunk.js b/ydb/core/viewer/monitoring/static/js/2016.397296b7.chunk.js deleted file mode 100644 index 545964cc19b7..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2016.397296b7.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2016.397296b7.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2016],{92016:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>r,language:()=>s});var r={comments:{lineComment:"#",blockComment:["=begin","=end"]},brackets:[["(",")"],["{","}"],["[","]"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],indentationRules:{increaseIndentPattern:new RegExp("^\\s*((begin|class|(private|protected)\\s+def|def|else|elsif|ensure|for|if|module|rescue|unless|until|when|while|case)|([^#]*\\sdo\\b)|([^#]*=\\s*(case|if|unless)))\\b([^#\\{;]|(\"|'|/).*\\4)*(#.*)?$"),decreaseIndentPattern:new RegExp("^\\s*([}\\]]([,)]?\\s*(#|$)|\\.[a-zA-Z_]\\w*\\b)|(end|rescue|ensure|else|elsif|when)\\b)")}},s={tokenPostfix:".ruby",keywords:["__LINE__","__ENCODING__","__FILE__","BEGIN","END","alias","and","begin","break","case","class","def","defined?","do","else","elsif","end","ensure","for","false","if","in","module","next","nil","not","or","redo","rescue","retry","return","self","super","then","true","undef","unless","until","when","while","yield"],keywordops:["::","..","...","?",":","=>"],builtins:["require","public","private","include","extend","attr_reader","protected","private_class_method","protected_class_method","new"],declarations:["module","class","def","case","do","begin","for","if","while","until","unless"],linedecls:["def","case","do","begin","for","if","while","until","unless"],operators:["^","&","|","<=>","==","===","!~","=~",">",">=","<","<=","<<",">>","+","-","*","/","%","**","~","+@","-@","[]","[]=","`","+=","-=","*=","**=","/=","^=","%=","<<=",">>=","&=","&&=","||=","|="],brackets:[{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"}],symbols:/[=>"}],[/%([qws])(@delim)/,{token:"string.$1.delim",switchTo:"@qstring.$1.$2.$2"}],[/%r\(/,{token:"regexp.delim",switchTo:"@pregexp.(.)"}],[/%r\[/,{token:"regexp.delim",switchTo:"@pregexp.[.]"}],[/%r\{/,{token:"regexp.delim",switchTo:"@pregexp.{.}"}],[/%r"}],[/%r(@delim)/,{token:"regexp.delim",switchTo:"@pregexp.$1.$1"}],[/%(x|W|Q?)\(/,{token:"string.$1.delim",switchTo:"@qqstring.$1.(.)"}],[/%(x|W|Q?)\[/,{token:"string.$1.delim",switchTo:"@qqstring.$1.[.]"}],[/%(x|W|Q?)\{/,{token:"string.$1.delim",switchTo:"@qqstring.$1.{.}"}],[/%(x|W|Q?)"}],[/%(x|W|Q?)(@delim)/,{token:"string.$1.delim",switchTo:"@qqstring.$1.$2.$2"}],[/%([rqwsxW]|Q?)./,{token:"invalid",next:"@pop"}],[/./,{token:"invalid",next:"@pop"}]],qstring:[[/\\$/,"string.$S2.escape"],[/\\./,"string.$S2.escape"],[/./,{cases:{"$#==$S4":{token:"string.$S2.delim",next:"@pop"},"$#==$S3":{token:"string.$S2.delim",next:"@push"},"@default":"string.$S2"}}]],qqstring:[[/#/,"string.$S2.escape","@interpolated"],{include:"@qstring"}],whitespace:[[/[ \t\r\n]+/,""],[/^\s*=begin\b/,"comment","@comment"],[/#.*$/,"comment"]],comment:[[/[^=]+/,"comment"],[/^\s*=begin\b/,"comment.invalid"],[/^\s*=end\b.*/,"comment","@pop"],[/[=]/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2042.81e83eeb.chunk.js b/ydb/core/viewer/monitoring/static/js/2042.81e83eeb.chunk.js deleted file mode 100644 index 4f91897edaf6..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2042.81e83eeb.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2042.81e83eeb.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2042],{62042:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>i,language:()=>_});var i={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*#pragma\\s+region\\b"),end:new RegExp("^\\s*#pragma\\s+endregion\\b")}}},_={defaultToken:"",tokenPostfix:".cpp",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["abstract","amp","array","auto","bool","break","case","catch","char","class","const","constexpr","const_cast","continue","cpu","decltype","default","delegate","delete","do","double","dynamic_cast","each","else","enum","event","explicit","export","extern","false","final","finally","float","for","friend","gcnew","generic","goto","if","in","initonly","inline","int","interface","interior_ptr","internal","literal","long","mutable","namespace","new","noexcept","nullptr","__nullptr","operator","override","partial","pascal","pin_ptr","private","property","protected","public","ref","register","reinterpret_cast","restrict","return","safe_cast","sealed","short","signed","sizeof","static","static_assert","static_cast","struct","switch","template","this","thread_local","throw","tile_static","true","try","typedef","typeid","typename","union","unsigned","using","virtual","void","volatile","wchar_t","where","while","_asm","_based","_cdecl","_declspec","_fastcall","_if_exists","_if_not_exists","_inline","_multiple_inheritance","_pascal","_single_inheritance","_stdcall","_virtual_inheritance","_w64","__abstract","__alignof","__asm","__assume","__based","__box","__builtin_alignof","__cdecl","__clrcall","__declspec","__delegate","__event","__except","__fastcall","__finally","__forceinline","__gc","__hook","__identifier","__if_exists","__if_not_exists","__inline","__int128","__int16","__int32","__int64","__int8","__interface","__leave","__m128","__m128d","__m128i","__m256","__m256d","__m256i","__m512","__m512d","__m512i","__m64","__multiple_inheritance","__newslot","__nogc","__noop","__nounwind","__novtordisp","__pascal","__pin","__pragma","__property","__ptr32","__ptr64","__raise","__restrict","__resume","__sealed","__single_inheritance","__stdcall","__super","__thiscall","__try","__try_cast","__typeof","__unaligned","__unhook","__uuidof","__value","__virtual_inheritance","__w64","__wchar_t"],operators:["=",">","<","!","~","?",":","==","<=",">=","!=","&&","||","++","--","+","-","*","/","&","|","^","%","<<",">>","+=","-=","*=","/=","&=","|=","^=","%=","<<=",">>="],symbols:/[=>\[\]]/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?(@floatsuffix)/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?(@floatsuffix)/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F](@integersuffix)/,"number.hex"],[/0[0-7']*[0-7](@integersuffix)/,"number.octal"],[/0[bB][0-1']*[0-1](@integersuffix)/,"number.binary"],[/\d[\d']*\d(@integersuffix)/,"number"],[/\d(@integersuffix)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*\\$/,"comment","@linecomment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],linecomment:[[/.*[^\\]$/,"comment","@pop"],[/[^]+/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],raw:[[/[^)]+/,"string.raw"],[/\)$S2\"/,{token:"string.raw.end",next:"@pop"}],[/\)/,"string.raw"]],annotation:[{include:"@whitespace"},[/using|alignas/,"keyword"],[/[a-zA-Z0-9_]+/,"annotation"],[/[,:]/,"delimiter"],[/[()]/,"@brackets"],[/\]\s*\]/,{token:"annotation",next:"@pop"}]],include:[[/(\s*)(<)([^<>]*)(>)/,["","keyword.directive.include.begin","string.include.identifier",{token:"keyword.directive.include.end",next:"@pop"}]],[/(\s*)(")([^"]*)(")/,["","keyword.directive.include.begin","string.include.identifier",{token:"keyword.directive.include.end",next:"@pop"}]]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2053.b4294b46.chunk.js b/ydb/core/viewer/monitoring/static/js/2053.b4294b46.chunk.js deleted file mode 100644 index b6576daf7909..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2053.b4294b46.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2053],{82053:function(e,_,n){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var n=_(e),t={name:"jv",weekdays:"Minggu_Senen_Seloso_Rebu_Kemis_Jemuwah_Septu".split("_"),months:"Januari_Februari_Maret_April_Mei_Juni_Juli_Agustus_September_Oktober_Nopember_Desember".split("_"),weekStart:1,weekdaysShort:"Min_Sen_Sel_Reb_Kem_Jem_Sep".split("_"),monthsShort:"Jan_Feb_Mar_Apr_Mei_Jun_Jul_Ags_Sep_Okt_Nop_Des".split("_"),weekdaysMin:"Mg_Sn_Sl_Rb_Km_Jm_Sp".split("_"),ordinal:function(e){return e},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [pukul] HH.mm",LLLL:"dddd, D MMMM YYYY [pukul] HH.mm"},relativeTime:{future:"wonten ing %s",past:"%s ingkang kepengker",s:"sawetawis detik",m:"setunggal menit",mm:"%d menit",h:"setunggal jam",hh:"%d jam",d:"sedinten",dd:"%d dinten",M:"sewulan",MM:"%d wulan",y:"setaun",yy:"%d taun"}};return n.default.locale(t,null,!0),t}(n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/20535.b2fdb3bf.chunk.js b/ydb/core/viewer/monitoring/static/js/20535.b2fdb3bf.chunk.js new file mode 100644 index 000000000000..098be20568df --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/20535.b2fdb3bf.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[20535],{20535:(e,t,a)=>{a.d(t,{default:()=>r});var o=a(53188);const r=a.n(o)()},53188:e=>{function t(e){e.languages.sqf=e.languages.extend("clike",{string:{pattern:/"(?:(?:"")?[^"])*"(?!")|'(?:[^'])*'/,greedy:!0},keyword:/\b(?:breakOut|breakTo|call|case|catch|default|do|echo|else|execFSM|execVM|exitWith|for|forEach|forEachMember|forEachMemberAgent|forEachMemberTeam|from|goto|if|nil|preprocessFile|preprocessFileLineNumbers|private|scopeName|spawn|step|switch|then|throw|to|try|while|with)\b/i,boolean:/\b(?:false|true)\b/i,function:/\b(?:abs|accTime|acos|action|actionIDs|actionKeys|actionKeysImages|actionKeysNames|actionKeysNamesArray|actionName|actionParams|activateAddons|activatedAddons|activateKey|add3DENConnection|add3DENEventHandler|add3DENLayer|addAction|addBackpack|addBackpackCargo|addBackpackCargoGlobal|addBackpackGlobal|addCamShake|addCuratorAddons|addCuratorCameraArea|addCuratorEditableObjects|addCuratorEditingArea|addCuratorPoints|addEditorObject|addEventHandler|addForce|addForceGeneratorRTD|addGoggles|addGroupIcon|addHandgunItem|addHeadgear|addItem|addItemCargo|addItemCargoGlobal|addItemPool|addItemToBackpack|addItemToUniform|addItemToVest|addLiveStats|addMagazine|addMagazineAmmoCargo|addMagazineCargo|addMagazineCargoGlobal|addMagazineGlobal|addMagazinePool|addMagazines|addMagazineTurret|addMenu|addMenuItem|addMissionEventHandler|addMPEventHandler|addMusicEventHandler|addOwnedMine|addPlayerScores|addPrimaryWeaponItem|addPublicVariableEventHandler|addRating|addResources|addScore|addScoreSide|addSecondaryWeaponItem|addSwitchableUnit|addTeamMember|addToRemainsCollector|addTorque|addUniform|addVehicle|addVest|addWaypoint|addWeapon|addWeaponCargo|addWeaponCargoGlobal|addWeaponGlobal|addWeaponItem|addWeaponPool|addWeaponTurret|admin|agent|agents|AGLToASL|aimedAtTarget|aimPos|airDensityCurveRTD|airDensityRTD|airplaneThrottle|airportSide|AISFinishHeal|alive|all3DENEntities|allAirports|allControls|allCurators|allCutLayers|allDead|allDeadMen|allDisplays|allGroups|allMapMarkers|allMines|allMissionObjects|allow3DMode|allowCrewInImmobile|allowCuratorLogicIgnoreAreas|allowDamage|allowDammage|allowFileOperations|allowFleeing|allowGetIn|allowSprint|allPlayers|allSimpleObjects|allSites|allTurrets|allUnits|allUnitsUAV|allVariables|ammo|ammoOnPylon|animate|animateBay|animateDoor|animatePylon|animateSource|animationNames|animationPhase|animationSourcePhase|animationState|append|apply|armoryPoints|arrayIntersect|asin|ASLToAGL|ASLToATL|assert|assignAsCargo|assignAsCargoIndex|assignAsCommander|assignAsDriver|assignAsGunner|assignAsTurret|assignCurator|assignedCargo|assignedCommander|assignedDriver|assignedGunner|assignedItems|assignedTarget|assignedTeam|assignedVehicle|assignedVehicleRole|assignItem|assignTeam|assignToAirport|atan|atan2|atg|ATLToASL|attachedObject|attachedObjects|attachedTo|attachObject|attachTo|attackEnabled|backpack|backpackCargo|backpackContainer|backpackItems|backpackMagazines|backpackSpaceFor|behaviour|benchmark|binocular|blufor|boundingBox|boundingBoxReal|boundingCenter|briefingName|buildingExit|buildingPos|buldozer_EnableRoadDiag|buldozer_IsEnabledRoadDiag|buldozer_LoadNewRoads|buldozer_reloadOperMap|buttonAction|buttonSetAction|cadetMode|callExtension|camCommand|camCommit|camCommitPrepared|camCommitted|camConstuctionSetParams|camCreate|camDestroy|cameraEffect|cameraEffectEnableHUD|cameraInterest|cameraOn|cameraView|campaignConfigFile|camPreload|camPreloaded|camPrepareBank|camPrepareDir|camPrepareDive|camPrepareFocus|camPrepareFov|camPrepareFovRange|camPreparePos|camPrepareRelPos|camPrepareTarget|camSetBank|camSetDir|camSetDive|camSetFocus|camSetFov|camSetFovRange|camSetPos|camSetRelPos|camSetTarget|camTarget|camUseNVG|canAdd|canAddItemToBackpack|canAddItemToUniform|canAddItemToVest|cancelSimpleTaskDestination|canFire|canMove|canSlingLoad|canStand|canSuspend|canTriggerDynamicSimulation|canUnloadInCombat|canVehicleCargo|captive|captiveNum|cbChecked|cbSetChecked|ceil|channelEnabled|cheatsEnabled|checkAIFeature|checkVisibility|civilian|className|clear3DENAttribute|clear3DENInventory|clearAllItemsFromBackpack|clearBackpackCargo|clearBackpackCargoGlobal|clearForcesRTD|clearGroupIcons|clearItemCargo|clearItemCargoGlobal|clearItemPool|clearMagazineCargo|clearMagazineCargoGlobal|clearMagazinePool|clearOverlay|clearRadio|clearVehicleInit|clearWeaponCargo|clearWeaponCargoGlobal|clearWeaponPool|clientOwner|closeDialog|closeDisplay|closeOverlay|collapseObjectTree|collect3DENHistory|collectiveRTD|combatMode|commandArtilleryFire|commandChat|commander|commandFire|commandFollow|commandFSM|commandGetOut|commandingMenu|commandMove|commandRadio|commandStop|commandSuppressiveFire|commandTarget|commandWatch|comment|commitOverlay|compile|compileFinal|completedFSM|composeText|configClasses|configFile|configHierarchy|configName|configNull|configProperties|configSourceAddonList|configSourceMod|configSourceModList|confirmSensorTarget|connectTerminalToUAV|controlNull|controlsGroupCtrl|copyFromClipboard|copyToClipboard|copyWaypoints|cos|count|countEnemy|countFriendly|countSide|countType|countUnknown|create3DENComposition|create3DENEntity|createAgent|createCenter|createDialog|createDiaryLink|createDiaryRecord|createDiarySubject|createDisplay|createGearDialog|createGroup|createGuardedPoint|createLocation|createMarker|createMarkerLocal|createMenu|createMine|createMissionDisplay|createMPCampaignDisplay|createSimpleObject|createSimpleTask|createSite|createSoundSource|createTask|createTeam|createTrigger|createUnit|createVehicle|createVehicleCrew|createVehicleLocal|crew|ctAddHeader|ctAddRow|ctClear|ctCurSel|ctData|ctFindHeaderRows|ctFindRowHeader|ctHeaderControls|ctHeaderCount|ctRemoveHeaders|ctRemoveRows|ctrlActivate|ctrlAddEventHandler|ctrlAngle|ctrlAutoScrollDelay|ctrlAutoScrollRewind|ctrlAutoScrollSpeed|ctrlChecked|ctrlClassName|ctrlCommit|ctrlCommitted|ctrlCreate|ctrlDelete|ctrlEnable|ctrlEnabled|ctrlFade|ctrlHTMLLoaded|ctrlIDC|ctrlIDD|ctrlMapAnimAdd|ctrlMapAnimClear|ctrlMapAnimCommit|ctrlMapAnimDone|ctrlMapCursor|ctrlMapMouseOver|ctrlMapScale|ctrlMapScreenToWorld|ctrlMapWorldToScreen|ctrlModel|ctrlModelDirAndUp|ctrlModelScale|ctrlParent|ctrlParentControlsGroup|ctrlPosition|ctrlRemoveAllEventHandlers|ctrlRemoveEventHandler|ctrlScale|ctrlSetActiveColor|ctrlSetAngle|ctrlSetAutoScrollDelay|ctrlSetAutoScrollRewind|ctrlSetAutoScrollSpeed|ctrlSetBackgroundColor|ctrlSetChecked|ctrlSetDisabledColor|ctrlSetEventHandler|ctrlSetFade|ctrlSetFocus|ctrlSetFont|ctrlSetFontH1|ctrlSetFontH1B|ctrlSetFontH2|ctrlSetFontH2B|ctrlSetFontH3|ctrlSetFontH3B|ctrlSetFontH4|ctrlSetFontH4B|ctrlSetFontH5|ctrlSetFontH5B|ctrlSetFontH6|ctrlSetFontH6B|ctrlSetFontHeight|ctrlSetFontHeightH1|ctrlSetFontHeightH2|ctrlSetFontHeightH3|ctrlSetFontHeightH4|ctrlSetFontHeightH5|ctrlSetFontHeightH6|ctrlSetFontHeightSecondary|ctrlSetFontP|ctrlSetFontPB|ctrlSetFontSecondary|ctrlSetForegroundColor|ctrlSetModel|ctrlSetModelDirAndUp|ctrlSetModelScale|ctrlSetPixelPrecision|ctrlSetPosition|ctrlSetScale|ctrlSetStructuredText|ctrlSetText|ctrlSetTextColor|ctrlSetTextColorSecondary|ctrlSetTextSecondary|ctrlSetTooltip|ctrlSetTooltipColorBox|ctrlSetTooltipColorShade|ctrlSetTooltipColorText|ctrlShow|ctrlShown|ctrlText|ctrlTextHeight|ctrlTextSecondary|ctrlTextWidth|ctrlType|ctrlVisible|ctRowControls|ctRowCount|ctSetCurSel|ctSetData|ctSetHeaderTemplate|ctSetRowTemplate|ctSetValue|ctValue|curatorAddons|curatorCamera|curatorCameraArea|curatorCameraAreaCeiling|curatorCoef|curatorEditableObjects|curatorEditingArea|curatorEditingAreaType|curatorMouseOver|curatorPoints|curatorRegisteredObjects|curatorSelected|curatorWaypointCost|current3DENOperation|currentChannel|currentCommand|currentMagazine|currentMagazineDetail|currentMagazineDetailTurret|currentMagazineTurret|currentMuzzle|currentNamespace|currentTask|currentTasks|currentThrowable|currentVisionMode|currentWaypoint|currentWeapon|currentWeaponMode|currentWeaponTurret|currentZeroing|cursorObject|cursorTarget|customChat|customRadio|cutFadeOut|cutObj|cutRsc|cutText|damage|date|dateToNumber|daytime|deActivateKey|debriefingText|debugFSM|debugLog|deg|delete3DENEntities|deleteAt|deleteCenter|deleteCollection|deleteEditorObject|deleteGroup|deleteGroupWhenEmpty|deleteIdentity|deleteLocation|deleteMarker|deleteMarkerLocal|deleteRange|deleteResources|deleteSite|deleteStatus|deleteTeam|deleteVehicle|deleteVehicleCrew|deleteWaypoint|detach|detectedMines|diag_activeMissionFSMs|diag_activeScripts|diag_activeSQFScripts|diag_activeSQSScripts|diag_captureFrame|diag_captureFrameToFile|diag_captureSlowFrame|diag_codePerformance|diag_drawMode|diag_dynamicSimulationEnd|diag_enable|diag_enabled|diag_fps|diag_fpsMin|diag_frameNo|diag_lightNewLoad|diag_list|diag_log|diag_logSlowFrame|diag_mergeConfigFile|diag_recordTurretLimits|diag_setLightNew|diag_tickTime|diag_toggle|dialog|diarySubjectExists|didJIP|didJIPOwner|difficulty|difficultyEnabled|difficultyEnabledRTD|difficultyOption|direction|directSay|disableAI|disableCollisionWith|disableConversation|disableDebriefingStats|disableMapIndicators|disableNVGEquipment|disableRemoteSensors|disableSerialization|disableTIEquipment|disableUAVConnectability|disableUserInput|displayAddEventHandler|displayCtrl|displayNull|displayParent|displayRemoveAllEventHandlers|displayRemoveEventHandler|displaySetEventHandler|dissolveTeam|distance|distance2D|distanceSqr|distributionRegion|do3DENAction|doArtilleryFire|doFire|doFollow|doFSM|doGetOut|doMove|doorPhase|doStop|doSuppressiveFire|doTarget|doWatch|drawArrow|drawEllipse|drawIcon|drawIcon3D|drawLine|drawLine3D|drawLink|drawLocation|drawPolygon|drawRectangle|drawTriangle|driver|drop|dynamicSimulationDistance|dynamicSimulationDistanceCoef|dynamicSimulationEnabled|dynamicSimulationSystemEnabled|east|edit3DENMissionAttributes|editObject|editorSetEventHandler|effectiveCommander|emptyPositions|enableAI|enableAIFeature|enableAimPrecision|enableAttack|enableAudioFeature|enableAutoStartUpRTD|enableAutoTrimRTD|enableCamShake|enableCaustics|enableChannel|enableCollisionWith|enableCopilot|enableDebriefingStats|enableDiagLegend|enableDynamicSimulation|enableDynamicSimulationSystem|enableEndDialog|enableEngineArtillery|enableEnvironment|enableFatigue|enableGunLights|enableInfoPanelComponent|enableIRLasers|enableMimics|enablePersonTurret|enableRadio|enableReload|enableRopeAttach|enableSatNormalOnDetail|enableSaving|enableSentences|enableSimulation|enableSimulationGlobal|enableStamina|enableStressDamage|enableTeamSwitch|enableTraffic|enableUAVConnectability|enableUAVWaypoints|enableVehicleCargo|enableVehicleSensor|enableWeaponDisassembly|endl|endLoadingScreen|endMission|engineOn|enginesIsOnRTD|enginesPowerRTD|enginesRpmRTD|enginesTorqueRTD|entities|environmentEnabled|estimatedEndServerTime|estimatedTimeLeft|evalObjectArgument|everyBackpack|everyContainer|exec|execEditorScript|exp|expectedDestination|exportJIPMessages|eyeDirection|eyePos|face|faction|fadeMusic|fadeRadio|fadeSound|fadeSpeech|failMission|fillWeaponsFromPool|find|findCover|findDisplay|findEditorObject|findEmptyPosition|findEmptyPositionReady|findIf|findNearestEnemy|finishMissionInit|finite|fire|fireAtTarget|firstBackpack|flag|flagAnimationPhase|flagOwner|flagSide|flagTexture|fleeing|floor|flyInHeight|flyInHeightASL|fog|fogForecast|fogParams|forceAddUniform|forceAtPositionRTD|forcedMap|forceEnd|forceFlagTexture|forceFollowRoad|forceGeneratorRTD|forceMap|forceRespawn|forceSpeed|forceWalk|forceWeaponFire|forceWeatherChange|forgetTarget|format|formation|formationDirection|formationLeader|formationMembers|formationPosition|formationTask|formatText|formLeader|freeLook|fromEditor|fuel|fullCrew|gearIDCAmmoCount|gearSlotAmmoCount|gearSlotData|get3DENActionState|get3DENAttribute|get3DENCamera|get3DENConnections|get3DENEntity|get3DENEntityID|get3DENGrid|get3DENIconsVisible|get3DENLayerEntities|get3DENLinesVisible|get3DENMissionAttribute|get3DENMouseOver|get3DENSelected|getAimingCoef|getAllEnvSoundControllers|getAllHitPointsDamage|getAllOwnedMines|getAllSoundControllers|getAmmoCargo|getAnimAimPrecision|getAnimSpeedCoef|getArray|getArtilleryAmmo|getArtilleryComputerSettings|getArtilleryETA|getAssignedCuratorLogic|getAssignedCuratorUnit|getBackpackCargo|getBleedingRemaining|getBurningValue|getCameraViewDirection|getCargoIndex|getCenterOfMass|getClientState|getClientStateNumber|getCompatiblePylonMagazines|getConnectedUAV|getContainerMaxLoad|getCursorObjectParams|getCustomAimCoef|getDammage|getDescription|getDir|getDirVisual|getDLCAssetsUsage|getDLCAssetsUsageByName|getDLCs|getDLCUsageTime|getEditorCamera|getEditorMode|getEditorObjectScope|getElevationOffset|getEngineTargetRpmRTD|getEnvSoundController|getFatigue|getFieldManualStartPage|getForcedFlagTexture|getFriend|getFSMVariable|getFuelCargo|getGroupIcon|getGroupIconParams|getGroupIcons|getHideFrom|getHit|getHitIndex|getHitPointDamage|getItemCargo|getMagazineCargo|getMarkerColor|getMarkerPos|getMarkerSize|getMarkerType|getMass|getMissionConfig|getMissionConfigValue|getMissionDLCs|getMissionLayerEntities|getMissionLayers|getModelInfo|getMousePosition|getMusicPlayedTime|getNumber|getObjectArgument|getObjectChildren|getObjectDLC|getObjectMaterials|getObjectProxy|getObjectTextures|getObjectType|getObjectViewDistance|getOxygenRemaining|getPersonUsedDLCs|getPilotCameraDirection|getPilotCameraPosition|getPilotCameraRotation|getPilotCameraTarget|getPlateNumber|getPlayerChannel|getPlayerScores|getPlayerUID|getPlayerUIDOld|getPos|getPosASL|getPosASLVisual|getPosASLW|getPosATL|getPosATLVisual|getPosVisual|getPosWorld|getPylonMagazines|getRelDir|getRelPos|getRemoteSensorsDisabled|getRepairCargo|getResolution|getRotorBrakeRTD|getShadowDistance|getShotParents|getSlingLoad|getSoundController|getSoundControllerResult|getSpeed|getStamina|getStatValue|getSuppression|getTerrainGrid|getTerrainHeightASL|getText|getTotalDLCUsageTime|getTrimOffsetRTD|getUnitLoadout|getUnitTrait|getUserMFDText|getUserMFDValue|getVariable|getVehicleCargo|getWeaponCargo|getWeaponSway|getWingsOrientationRTD|getWingsPositionRTD|getWPPos|glanceAt|globalChat|globalRadio|goggles|group|groupChat|groupFromNetId|groupIconSelectable|groupIconsVisible|groupId|groupOwner|groupRadio|groupSelectedUnits|groupSelectUnit|grpNull|gunner|gusts|halt|handgunItems|handgunMagazine|handgunWeapon|handsHit|hasInterface|hasPilotCamera|hasWeapon|hcAllGroups|hcGroupParams|hcLeader|hcRemoveAllGroups|hcRemoveGroup|hcSelected|hcSelectGroup|hcSetGroup|hcShowBar|hcShownBar|headgear|hideBody|hideObject|hideObjectGlobal|hideSelection|hint|hintC|hintCadet|hintSilent|hmd|hostMission|htmlLoad|HUDMovementLevels|humidity|image|importAllGroups|importance|in|inArea|inAreaArray|incapacitatedState|independent|inflame|inflamed|infoPanel|infoPanelComponentEnabled|infoPanelComponents|infoPanels|inGameUISetEventHandler|inheritsFrom|initAmbientLife|inPolygon|inputAction|inRangeOfArtillery|insertEditorObject|intersect|is3DEN|is3DENMultiplayer|isAbleToBreathe|isAgent|isAimPrecisionEnabled|isArray|isAutoHoverOn|isAutonomous|isAutoStartUpEnabledRTD|isAutotest|isAutoTrimOnRTD|isBleeding|isBurning|isClass|isCollisionLightOn|isCopilotEnabled|isDamageAllowed|isDedicated|isDLCAvailable|isEngineOn|isEqualTo|isEqualType|isEqualTypeAll|isEqualTypeAny|isEqualTypeArray|isEqualTypeParams|isFilePatchingEnabled|isFlashlightOn|isFlatEmpty|isForcedWalk|isFormationLeader|isGroupDeletedWhenEmpty|isHidden|isInRemainsCollector|isInstructorFigureEnabled|isIRLaserOn|isKeyActive|isKindOf|isLaserOn|isLightOn|isLocalized|isManualFire|isMarkedForCollection|isMultiplayer|isMultiplayerSolo|isNil|isNull|isNumber|isObjectHidden|isObjectRTD|isOnRoad|isPipEnabled|isPlayer|isRealTime|isRemoteExecuted|isRemoteExecutedJIP|isServer|isShowing3DIcons|isSimpleObject|isSprintAllowed|isStaminaEnabled|isSteamMission|isStreamFriendlyUIEnabled|isStressDamageEnabled|isText|isTouchingGround|isTurnedOut|isTutHintsEnabled|isUAVConnectable|isUAVConnected|isUIContext|isUniformAllowed|isVehicleCargo|isVehicleRadarOn|isVehicleSensorEnabled|isWalking|isWeaponDeployed|isWeaponRested|itemCargo|items|itemsWithMagazines|join|joinAs|joinAsSilent|joinSilent|joinString|kbAddDatabase|kbAddDatabaseTargets|kbAddTopic|kbHasTopic|kbReact|kbRemoveTopic|kbTell|kbWasSaid|keyImage|keyName|knowsAbout|land|landAt|landResult|language|laserTarget|lbAdd|lbClear|lbColor|lbColorRight|lbCurSel|lbData|lbDelete|lbIsSelected|lbPicture|lbPictureRight|lbSelection|lbSetColor|lbSetColorRight|lbSetCurSel|lbSetData|lbSetPicture|lbSetPictureColor|lbSetPictureColorDisabled|lbSetPictureColorSelected|lbSetPictureRight|lbSetPictureRightColor|lbSetPictureRightColorDisabled|lbSetPictureRightColorSelected|lbSetSelectColor|lbSetSelectColorRight|lbSetSelected|lbSetText|lbSetTextRight|lbSetTooltip|lbSetValue|lbSize|lbSort|lbSortByValue|lbText|lbTextRight|lbValue|leader|leaderboardDeInit|leaderboardGetRows|leaderboardInit|leaderboardRequestRowsFriends|leaderboardRequestRowsGlobal|leaderboardRequestRowsGlobalAroundUser|leaderboardsRequestUploadScore|leaderboardsRequestUploadScoreKeepBest|leaderboardState|leaveVehicle|libraryCredits|libraryDisclaimers|lifeState|lightAttachObject|lightDetachObject|lightIsOn|lightnings|limitSpeed|linearConversion|lineBreak|lineIntersects|lineIntersectsObjs|lineIntersectsSurfaces|lineIntersectsWith|linkItem|list|listObjects|listRemoteTargets|listVehicleSensors|ln|lnbAddArray|lnbAddColumn|lnbAddRow|lnbClear|lnbColor|lnbColorRight|lnbCurSelRow|lnbData|lnbDeleteColumn|lnbDeleteRow|lnbGetColumnsPosition|lnbPicture|lnbPictureRight|lnbSetColor|lnbSetColorRight|lnbSetColumnsPos|lnbSetCurSelRow|lnbSetData|lnbSetPicture|lnbSetPictureColor|lnbSetPictureColorRight|lnbSetPictureColorSelected|lnbSetPictureColorSelectedRight|lnbSetPictureRight|lnbSetText|lnbSetTextRight|lnbSetValue|lnbSize|lnbSort|lnbSortByValue|lnbText|lnbTextRight|lnbValue|load|loadAbs|loadBackpack|loadFile|loadGame|loadIdentity|loadMagazine|loadOverlay|loadStatus|loadUniform|loadVest|local|localize|locationNull|locationPosition|lock|lockCameraTo|lockCargo|lockDriver|locked|lockedCargo|lockedDriver|lockedTurret|lockIdentity|lockTurret|lockWP|log|logEntities|logNetwork|logNetworkTerminate|lookAt|lookAtPos|magazineCargo|magazines|magazinesAllTurrets|magazinesAmmo|magazinesAmmoCargo|magazinesAmmoFull|magazinesDetail|magazinesDetailBackpack|magazinesDetailUniform|magazinesDetailVest|magazinesTurret|magazineTurretAmmo|mapAnimAdd|mapAnimClear|mapAnimCommit|mapAnimDone|mapCenterOnCamera|mapGridPosition|markAsFinishedOnSteam|markerAlpha|markerBrush|markerColor|markerDir|markerPos|markerShape|markerSize|markerText|markerType|max|members|menuAction|menuAdd|menuChecked|menuClear|menuCollapse|menuData|menuDelete|menuEnable|menuEnabled|menuExpand|menuHover|menuPicture|menuSetAction|menuSetCheck|menuSetData|menuSetPicture|menuSetValue|menuShortcut|menuShortcutText|menuSize|menuSort|menuText|menuURL|menuValue|min|mineActive|mineDetectedBy|missionConfigFile|missionDifficulty|missionName|missionNamespace|missionStart|missionVersion|modelToWorld|modelToWorldVisual|modelToWorldVisualWorld|modelToWorldWorld|modParams|moonIntensity|moonPhase|morale|move|move3DENCamera|moveInAny|moveInCargo|moveInCommander|moveInDriver|moveInGunner|moveInTurret|moveObjectToEnd|moveOut|moveTime|moveTo|moveToCompleted|moveToFailed|musicVolume|name|nameSound|nearEntities|nearestBuilding|nearestLocation|nearestLocations|nearestLocationWithDubbing|nearestObject|nearestObjects|nearestTerrainObjects|nearObjects|nearObjectsReady|nearRoads|nearSupplies|nearTargets|needReload|netId|netObjNull|newOverlay|nextMenuItemIndex|nextWeatherChange|nMenuItems|numberOfEnginesRTD|numberToDate|objectCurators|objectFromNetId|objectParent|objNull|objStatus|onBriefingGear|onBriefingGroup|onBriefingNotes|onBriefingPlan|onBriefingTeamSwitch|onCommandModeChanged|onDoubleClick|onEachFrame|onGroupIconClick|onGroupIconOverEnter|onGroupIconOverLeave|onHCGroupSelectionChanged|onMapSingleClick|onPlayerConnected|onPlayerDisconnected|onPreloadFinished|onPreloadStarted|onShowNewObject|onTeamSwitch|openCuratorInterface|openDLCPage|openDSInterface|openMap|openSteamApp|openYoutubeVideo|opfor|orderGetIn|overcast|overcastForecast|owner|param|params|parseNumber|parseSimpleArray|parseText|parsingNamespace|particlesQuality|pi|pickWeaponPool|pitch|pixelGrid|pixelGridBase|pixelGridNoUIScale|pixelH|pixelW|playableSlotsNumber|playableUnits|playAction|playActionNow|player|playerRespawnTime|playerSide|playersNumber|playGesture|playMission|playMove|playMoveNow|playMusic|playScriptedMission|playSound|playSound3D|position|positionCameraToWorld|posScreenToWorld|posWorldToScreen|ppEffectAdjust|ppEffectCommit|ppEffectCommitted|ppEffectCreate|ppEffectDestroy|ppEffectEnable|ppEffectEnabled|ppEffectForceInNVG|precision|preloadCamera|preloadObject|preloadSound|preloadTitleObj|preloadTitleRsc|primaryWeapon|primaryWeaponItems|primaryWeaponMagazine|priority|processDiaryLink|processInitCommands|productVersion|profileName|profileNamespace|profileNameSteam|progressLoadingScreen|progressPosition|progressSetPosition|publicVariable|publicVariableClient|publicVariableServer|pushBack|pushBackUnique|putWeaponPool|queryItemsPool|queryMagazinePool|queryWeaponPool|rad|radioChannelAdd|radioChannelCreate|radioChannelRemove|radioChannelSetCallSign|radioChannelSetLabel|radioVolume|rain|rainbow|random|rank|rankId|rating|rectangular|registeredTasks|registerTask|reload|reloadEnabled|remoteControl|remoteExec|remoteExecCall|remoteExecutedOwner|remove3DENConnection|remove3DENEventHandler|remove3DENLayer|removeAction|removeAll3DENEventHandlers|removeAllActions|removeAllAssignedItems|removeAllContainers|removeAllCuratorAddons|removeAllCuratorCameraAreas|removeAllCuratorEditingAreas|removeAllEventHandlers|removeAllHandgunItems|removeAllItems|removeAllItemsWithMagazines|removeAllMissionEventHandlers|removeAllMPEventHandlers|removeAllMusicEventHandlers|removeAllOwnedMines|removeAllPrimaryWeaponItems|removeAllWeapons|removeBackpack|removeBackpackGlobal|removeCuratorAddons|removeCuratorCameraArea|removeCuratorEditableObjects|removeCuratorEditingArea|removeDrawIcon|removeDrawLinks|removeEventHandler|removeFromRemainsCollector|removeGoggles|removeGroupIcon|removeHandgunItem|removeHeadgear|removeItem|removeItemFromBackpack|removeItemFromUniform|removeItemFromVest|removeItems|removeMagazine|removeMagazineGlobal|removeMagazines|removeMagazinesTurret|removeMagazineTurret|removeMenuItem|removeMissionEventHandler|removeMPEventHandler|removeMusicEventHandler|removeOwnedMine|removePrimaryWeaponItem|removeSecondaryWeaponItem|removeSimpleTask|removeSwitchableUnit|removeTeamMember|removeUniform|removeVest|removeWeapon|removeWeaponAttachmentCargo|removeWeaponCargo|removeWeaponGlobal|removeWeaponTurret|reportRemoteTarget|requiredVersion|resetCamShake|resetSubgroupDirection|resistance|resize|resources|respawnVehicle|restartEditorCamera|reveal|revealMine|reverse|reversedMouseY|roadAt|roadsConnectedTo|roleDescription|ropeAttachedObjects|ropeAttachedTo|ropeAttachEnabled|ropeAttachTo|ropeCreate|ropeCut|ropeDestroy|ropeDetach|ropeEndPosition|ropeLength|ropes|ropeUnwind|ropeUnwound|rotorsForcesRTD|rotorsRpmRTD|round|runInitScript|safeZoneH|safeZoneW|safeZoneWAbs|safeZoneX|safeZoneXAbs|safeZoneY|save3DENInventory|saveGame|saveIdentity|saveJoysticks|saveOverlay|saveProfileNamespace|saveStatus|saveVar|savingEnabled|say|say2D|say3D|score|scoreSide|screenshot|screenToWorld|scriptDone|scriptName|scriptNull|scudState|secondaryWeapon|secondaryWeaponItems|secondaryWeaponMagazine|select|selectBestPlaces|selectDiarySubject|selectedEditorObjects|selectEditorObject|selectionNames|selectionPosition|selectLeader|selectMax|selectMin|selectNoPlayer|selectPlayer|selectRandom|selectRandomWeighted|selectWeapon|selectWeaponTurret|sendAUMessage|sendSimpleCommand|sendTask|sendTaskResult|sendUDPMessage|serverCommand|serverCommandAvailable|serverCommandExecutable|serverName|serverTime|set|set3DENAttribute|set3DENAttributes|set3DENGrid|set3DENIconsVisible|set3DENLayer|set3DENLinesVisible|set3DENLogicType|set3DENMissionAttribute|set3DENMissionAttributes|set3DENModelsVisible|set3DENObjectType|set3DENSelected|setAccTime|setActualCollectiveRTD|setAirplaneThrottle|setAirportSide|setAmmo|setAmmoCargo|setAmmoOnPylon|setAnimSpeedCoef|setAperture|setApertureNew|setArmoryPoints|setAttributes|setAutonomous|setBehaviour|setBleedingRemaining|setBrakesRTD|setCameraInterest|setCamShakeDefParams|setCamShakeParams|setCamUseTI|setCaptive|setCenterOfMass|setCollisionLight|setCombatMode|setCompassOscillation|setConvoySeparation|setCuratorCameraAreaCeiling|setCuratorCoef|setCuratorEditingAreaType|setCuratorWaypointCost|setCurrentChannel|setCurrentTask|setCurrentWaypoint|setCustomAimCoef|setCustomWeightRTD|setDamage|setDammage|setDate|setDebriefingText|setDefaultCamera|setDestination|setDetailMapBlendPars|setDir|setDirection|setDrawIcon|setDriveOnPath|setDropInterval|setDynamicSimulationDistance|setDynamicSimulationDistanceCoef|setEditorMode|setEditorObjectScope|setEffectCondition|setEngineRpmRTD|setFace|setFaceAnimation|setFatigue|setFeatureType|setFlagAnimationPhase|setFlagOwner|setFlagSide|setFlagTexture|setFog|setForceGeneratorRTD|setFormation|setFormationTask|setFormDir|setFriend|setFromEditor|setFSMVariable|setFuel|setFuelCargo|setGroupIcon|setGroupIconParams|setGroupIconsSelectable|setGroupIconsVisible|setGroupId|setGroupIdGlobal|setGroupOwner|setGusts|setHideBehind|setHit|setHitIndex|setHitPointDamage|setHorizonParallaxCoef|setHUDMovementLevels|setIdentity|setImportance|setInfoPanel|setLeader|setLightAmbient|setLightAttenuation|setLightBrightness|setLightColor|setLightDayLight|setLightFlareMaxDistance|setLightFlareSize|setLightIntensity|setLightnings|setLightUseFlare|setLocalWindParams|setMagazineTurretAmmo|setMarkerAlpha|setMarkerAlphaLocal|setMarkerBrush|setMarkerBrushLocal|setMarkerColor|setMarkerColorLocal|setMarkerDir|setMarkerDirLocal|setMarkerPos|setMarkerPosLocal|setMarkerShape|setMarkerShapeLocal|setMarkerSize|setMarkerSizeLocal|setMarkerText|setMarkerTextLocal|setMarkerType|setMarkerTypeLocal|setMass|setMimic|setMousePosition|setMusicEffect|setMusicEventHandler|setName|setNameSound|setObjectArguments|setObjectMaterial|setObjectMaterialGlobal|setObjectProxy|setObjectTexture|setObjectTextureGlobal|setObjectViewDistance|setOvercast|setOwner|setOxygenRemaining|setParticleCircle|setParticleClass|setParticleFire|setParticleParams|setParticleRandom|setPilotCameraDirection|setPilotCameraRotation|setPilotCameraTarget|setPilotLight|setPiPEffect|setPitch|setPlateNumber|setPlayable|setPlayerRespawnTime|setPos|setPosASL|setPosASL2|setPosASLW|setPosATL|setPosition|setPosWorld|setPylonLoadOut|setPylonsPriority|setRadioMsg|setRain|setRainbow|setRandomLip|setRank|setRectangular|setRepairCargo|setRotorBrakeRTD|setShadowDistance|setShotParents|setSide|setSimpleTaskAlwaysVisible|setSimpleTaskCustomData|setSimpleTaskDescription|setSimpleTaskDestination|setSimpleTaskTarget|setSimpleTaskType|setSimulWeatherLayers|setSize|setSkill|setSlingLoad|setSoundEffect|setSpeaker|setSpeech|setSpeedMode|setStamina|setStaminaScheme|setStatValue|setSuppression|setSystemOfUnits|setTargetAge|setTaskMarkerOffset|setTaskResult|setTaskState|setTerrainGrid|setText|setTimeMultiplier|setTitleEffect|setToneMapping|setToneMappingParams|setTrafficDensity|setTrafficDistance|setTrafficGap|setTrafficSpeed|setTriggerActivation|setTriggerArea|setTriggerStatements|setTriggerText|setTriggerTimeout|setTriggerType|setType|setUnconscious|setUnitAbility|setUnitLoadout|setUnitPos|setUnitPosWeak|setUnitRank|setUnitRecoilCoefficient|setUnitTrait|setUnloadInCombat|setUserActionText|setUserMFDText|setUserMFDValue|setVariable|setVectorDir|setVectorDirAndUp|setVectorUp|setVehicleAmmo|setVehicleAmmoDef|setVehicleArmor|setVehicleCargo|setVehicleId|setVehicleInit|setVehicleLock|setVehiclePosition|setVehicleRadar|setVehicleReceiveRemoteTargets|setVehicleReportOwnPosition|setVehicleReportRemoteTargets|setVehicleTIPars|setVehicleVarName|setVelocity|setVelocityModelSpace|setVelocityTransformation|setViewDistance|setVisibleIfTreeCollapsed|setWantedRpmRTD|setWaves|setWaypointBehaviour|setWaypointCombatMode|setWaypointCompletionRadius|setWaypointDescription|setWaypointForceBehaviour|setWaypointFormation|setWaypointHousePosition|setWaypointLoiterRadius|setWaypointLoiterType|setWaypointName|setWaypointPosition|setWaypointScript|setWaypointSpeed|setWaypointStatements|setWaypointTimeout|setWaypointType|setWaypointVisible|setWeaponReloadingTime|setWind|setWindDir|setWindForce|setWindStr|setWingForceScaleRTD|setWPPos|show3DIcons|showChat|showCinemaBorder|showCommandingMenu|showCompass|showCuratorCompass|showGPS|showHUD|showLegend|showMap|shownArtilleryComputer|shownChat|shownCompass|shownCuratorCompass|showNewEditorObject|shownGPS|shownHUD|shownMap|shownPad|shownRadio|shownScoretable|shownUAVFeed|shownWarrant|shownWatch|showPad|showRadio|showScoretable|showSubtitles|showUAVFeed|showWarrant|showWatch|showWaypoint|showWaypoints|side|sideAmbientLife|sideChat|sideEmpty|sideEnemy|sideFriendly|sideLogic|sideRadio|sideUnknown|simpleTasks|simulationEnabled|simulCloudDensity|simulCloudOcclusion|simulInClouds|simulWeatherSync|sin|size|sizeOf|skill|skillFinal|skipTime|sleep|sliderPosition|sliderRange|sliderSetPosition|sliderSetRange|sliderSetSpeed|sliderSpeed|slingLoadAssistantShown|soldierMagazines|someAmmo|sort|soundVolume|speaker|speed|speedMode|splitString|sqrt|squadParams|stance|startLoadingScreen|stop|stopEngineRTD|stopped|str|sunOrMoon|supportInfo|suppressFor|surfaceIsWater|surfaceNormal|surfaceType|swimInDepth|switchableUnits|switchAction|switchCamera|switchGesture|switchLight|switchMove|synchronizedObjects|synchronizedTriggers|synchronizedWaypoints|synchronizeObjectsAdd|synchronizeObjectsRemove|synchronizeTrigger|synchronizeWaypoint|systemChat|systemOfUnits|tan|targetKnowledge|targets|targetsAggregate|targetsQuery|taskAlwaysVisible|taskChildren|taskCompleted|taskCustomData|taskDescription|taskDestination|taskHint|taskMarkerOffset|taskNull|taskParent|taskResult|taskState|taskType|teamMember|teamMemberNull|teamName|teams|teamSwitch|teamSwitchEnabled|teamType|terminate|terrainIntersect|terrainIntersectASL|terrainIntersectAtASL|text|textLog|textLogFormat|tg|time|timeMultiplier|titleCut|titleFadeOut|titleObj|titleRsc|titleText|toArray|toFixed|toLower|toString|toUpper|triggerActivated|triggerActivation|triggerArea|triggerAttachedVehicle|triggerAttachObject|triggerAttachVehicle|triggerDynamicSimulation|triggerStatements|triggerText|triggerTimeout|triggerTimeoutCurrent|triggerType|turretLocal|turretOwner|turretUnit|tvAdd|tvClear|tvCollapse|tvCollapseAll|tvCount|tvCurSel|tvData|tvDelete|tvExpand|tvExpandAll|tvPicture|tvPictureRight|tvSetColor|tvSetCurSel|tvSetData|tvSetPicture|tvSetPictureColor|tvSetPictureColorDisabled|tvSetPictureColorSelected|tvSetPictureRight|tvSetPictureRightColor|tvSetPictureRightColorDisabled|tvSetPictureRightColorSelected|tvSetSelectColor|tvSetText|tvSetTooltip|tvSetValue|tvSort|tvSortByValue|tvText|tvTooltip|tvValue|type|typeName|typeOf|UAVControl|uiNamespace|uiSleep|unassignCurator|unassignItem|unassignTeam|unassignVehicle|underwater|uniform|uniformContainer|uniformItems|uniformMagazines|unitAddons|unitAimPosition|unitAimPositionVisual|unitBackpack|unitIsUAV|unitPos|unitReady|unitRecoilCoefficient|units|unitsBelowHeight|unlinkItem|unlockAchievement|unregisterTask|updateDrawIcon|updateMenuItem|updateObjectTree|useAIOperMapObstructionTest|useAISteeringComponent|useAudioTimeForMoves|userInputDisabled|vectorAdd|vectorCos|vectorCrossProduct|vectorDiff|vectorDir|vectorDirVisual|vectorDistance|vectorDistanceSqr|vectorDotProduct|vectorFromTo|vectorMagnitude|vectorMagnitudeSqr|vectorModelToWorld|vectorModelToWorldVisual|vectorMultiply|vectorNormalized|vectorUp|vectorUpVisual|vectorWorldToModel|vectorWorldToModelVisual|vehicle|vehicleCargoEnabled|vehicleChat|vehicleRadio|vehicleReceiveRemoteTargets|vehicleReportOwnPosition|vehicleReportRemoteTargets|vehicles|vehicleVarName|velocity|velocityModelSpace|verifySignature|vest|vestContainer|vestItems|vestMagazines|viewDistance|visibleCompass|visibleGPS|visibleMap|visiblePosition|visiblePositionASL|visibleScoretable|visibleWatch|waitUntil|waves|waypointAttachedObject|waypointAttachedVehicle|waypointAttachObject|waypointAttachVehicle|waypointBehaviour|waypointCombatMode|waypointCompletionRadius|waypointDescription|waypointForceBehaviour|waypointFormation|waypointHousePosition|waypointLoiterRadius|waypointLoiterType|waypointName|waypointPosition|waypoints|waypointScript|waypointsEnabledUAV|waypointShow|waypointSpeed|waypointStatements|waypointTimeout|waypointTimeoutCurrent|waypointType|waypointVisible|weaponAccessories|weaponAccessoriesCargo|weaponCargo|weaponDirection|weaponInertia|weaponLowered|weapons|weaponsItems|weaponsItemsCargo|weaponState|weaponsTurret|weightRTD|west|WFSideText|wind|windDir|windRTD|windStr|wingsForcesRTD|worldName|worldSize|worldToModel|worldToModelVisual|worldToScreen)\b/i,number:/(?:\$|\b0x)[\da-f]+\b|(?:\B\.\d+|\b\d+(?:\.\d+)?)(?:e[+-]?\d+)?\b/i,operator:/##|>>|&&|\|\||[!=<>]=?|[-+*/%#^]|\b(?:and|mod|not|or)\b/i,"magic-variable":{pattern:/\b(?:this|thisList|thisTrigger|_exception|_fnc_scriptName|_fnc_scriptNameParent|_forEachIndex|_this|_thisEventHandler|_thisFSM|_thisScript|_x)\b/i,alias:"keyword"},constant:/\bDIK(?:_[a-z\d]+)+\b/i}),e.languages.insertBefore("sqf","string",{macro:{pattern:/(^[ \t]*)#[a-z](?:[^\r\n\\]|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{directive:{pattern:/#[a-z]+\b/i,alias:"keyword"},comment:e.languages.sqf.comment}}}),delete e.languages.sqf["class-name"]}e.exports=t,t.displayName="sqf",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/20600.6e1ccb0d.chunk.js b/ydb/core/viewer/monitoring/static/js/20600.6e1ccb0d.chunk.js new file mode 100644 index 000000000000..0a0a1a4bf22a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/20600.6e1ccb0d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[20600],{14707:e=>{function n(e){!function(e){var n=/\((?:[^()]|\((?:[^()]|\([^()]*\))*\))*\)/.source,t=/(?:\b\w+(?:)?|)/.source.replace(//g,(function(){return n})),i=e.languages.pascaligo={comment:/\(\*[\s\S]+?\*\)|\/\/.*/,string:{pattern:/(["'`])(?:\\[\s\S]|(?!\1)[^\\])*\1|\^[a-z]/i,greedy:!0},"class-name":[{pattern:RegExp(/(\btype\s+\w+\s+is\s+)/.source.replace(//g,(function(){return t})),"i"),lookbehind:!0,inside:null},{pattern:RegExp(/(?=\s+is\b)/.source.replace(//g,(function(){return t})),"i"),inside:null},{pattern:RegExp(/(:\s*)/.source.replace(//g,(function(){return t}))),lookbehind:!0,inside:null}],keyword:{pattern:/(^|[^&])\b(?:begin|block|case|const|else|end|fail|for|from|function|if|is|nil|of|remove|return|skip|then|type|var|while|with)\b/i,lookbehind:!0},boolean:{pattern:/(^|[^&])\b(?:False|True)\b/i,lookbehind:!0},builtin:{pattern:/(^|[^&])\b(?:bool|int|list|map|nat|record|string|unit)\b/i,lookbehind:!0},function:/\b\w+(?=\s*\()/,number:[/%[01]+|&[0-7]+|\$[a-f\d]+/i,/\b\d+(?:\.\d+)?(?:e[+-]?\d+)?(?:mtz|n)?/i],operator:/->|=\/=|\.\.|\*\*|:=|<[<=>]?|>[>=]?|[+\-*\/]=?|[@^=|]|\b(?:and|mod|or)\b/,punctuation:/\(\.|\.\)|[()\[\]:;,.{}]/},o=["comment","keyword","builtin","operator","punctuation"].reduce((function(e,n){return e[n]=i[n],e}),{});i["class-name"].forEach((function(e){e.inside=o}))}(e)}e.exports=n,n.displayName="pascaligo",n.aliases=[]},20600:(e,n,t)=>{t.d(n,{default:()=>o});var i=t(14707);const o=t.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/20654.f715fac2.chunk.js b/ydb/core/viewer/monitoring/static/js/20654.f715fac2.chunk.js new file mode 100644 index 000000000000..867f655a7fa0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/20654.f715fac2.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 20654.f715fac2.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[20654],{20654:(e,s,o)=>{o.r(s),o.d(s,{conf:()=>t,language:()=>n});var t={comments:{lineComment:"REM"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],surroundingPairs:[{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],folding:{markers:{start:new RegExp("^\\s*(::\\s*|REM\\s+)#region"),end:new RegExp("^\\s*(::\\s*|REM\\s+)#endregion")}}},n={defaultToken:"",ignoreCase:!0,tokenPostfix:".bat",brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:/call|defined|echo|errorlevel|exist|for|goto|if|pause|set|shift|start|title|not|pushd|popd/,symbols:/[=>{function T(E){E.languages.basic={comment:{pattern:/(?:!|REM\b).+/i,inside:{keyword:/^REM/i}},string:{pattern:/"(?:""|[!#$%&'()*,\/:;<=>?^\w +\-.])*"/,greedy:!0},number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:E[+-]?\d+)?/i,keyword:/\b(?:AS|BEEP|BLOAD|BSAVE|CALL(?: ABSOLUTE)?|CASE|CHAIN|CHDIR|CLEAR|CLOSE|CLS|COM|COMMON|CONST|DATA|DECLARE|DEF(?: FN| SEG|DBL|INT|LNG|SNG|STR)|DIM|DO|DOUBLE|ELSE|ELSEIF|END|ENVIRON|ERASE|ERROR|EXIT|FIELD|FILES|FOR|FUNCTION|GET|GOSUB|GOTO|IF|INPUT|INTEGER|IOCTL|KEY|KILL|LINE INPUT|LOCATE|LOCK|LONG|LOOP|LSET|MKDIR|NAME|NEXT|OFF|ON(?: COM| ERROR| KEY| TIMER)?|OPEN|OPTION BASE|OUT|POKE|PUT|READ|REDIM|REM|RESTORE|RESUME|RETURN|RMDIR|RSET|RUN|SELECT CASE|SHARED|SHELL|SINGLE|SLEEP|STATIC|STEP|STOP|STRING|SUB|SWAP|SYSTEM|THEN|TIMER|TO|TROFF|TRON|TYPE|UNLOCK|UNTIL|USING|VIEW PRINT|WAIT|WEND|WHILE|WRITE)(?:\$|\b)/i,function:/\b(?:ABS|ACCESS|ACOS|ANGLE|AREA|ARITHMETIC|ARRAY|ASIN|ASK|AT|ATN|BASE|BEGIN|BREAK|CAUSE|CEIL|CHR|CLIP|COLLATE|COLOR|CON|COS|COSH|COT|CSC|DATE|DATUM|DEBUG|DECIMAL|DEF|DEG|DEGREES|DELETE|DET|DEVICE|DISPLAY|DOT|ELAPSED|EPS|ERASABLE|EXLINE|EXP|EXTERNAL|EXTYPE|FILETYPE|FIXED|FP|GO|GRAPH|HANDLER|IDN|IMAGE|IN|INT|INTERNAL|IP|IS|KEYED|LBOUND|LCASE|LEFT|LEN|LENGTH|LET|LINE|LINES|LOG|LOG10|LOG2|LTRIM|MARGIN|MAT|MAX|MAXNUM|MID|MIN|MISSING|MOD|NATIVE|NUL|NUMERIC|OF|OPTION|ORD|ORGANIZATION|OUTIN|OUTPUT|PI|POINT|POINTER|POINTS|POS|PRINT|PROGRAM|PROMPT|RAD|RADIANS|RANDOMIZE|RECORD|RECSIZE|RECTYPE|RELATIVE|REMAINDER|REPEAT|REST|RETRY|REWRITE|RIGHT|RND|ROUND|RTRIM|SAME|SEC|SELECT|SEQUENTIAL|SET|SETTER|SGN|SIN|SINH|SIZE|SKIP|SQR|STANDARD|STATUS|STR|STREAM|STYLE|TAB|TAN|TANH|TEMPLATE|TEXT|THERE|TIME|TIMEOUT|TRACE|TRANSFORM|TRUNCATE|UBOUND|UCASE|USE|VAL|VARIABLE|VIEWPORT|WHEN|WINDOW|WITH|ZER|ZONEWIDTH)(?:\$|\b)/i,operator:/<[=>]?|>=?|[+\-*\/^=&]|\b(?:AND|EQV|IMP|NOT|OR|XOR)\b/i,punctuation:/[,;:()]/}}E.exports=T,T.displayName="basic",T.aliases=[]},21742:(E,T,R)=>{R.d(T,{default:()=>I});var N=R(54061);const I=R.n(N)()},54061:(E,T,R)=>{var N=R(7208);function I(E){E.register(N),E.languages.vbnet=E.languages.extend("basic",{comment:[{pattern:/(?:!|REM\b).+/i,inside:{keyword:/^REM/i}},{pattern:/(^|[^\\:])'.*/,lookbehind:!0,greedy:!0}],string:{pattern:/(^|[^"])"(?:""|[^"])*"(?!")/,lookbehind:!0,greedy:!0},keyword:/(?:\b(?:ADDHANDLER|ADDRESSOF|ALIAS|AND|ANDALSO|AS|BEEP|BLOAD|BOOLEAN|BSAVE|BYREF|BYTE|BYVAL|CALL(?: ABSOLUTE)?|CASE|CATCH|CBOOL|CBYTE|CCHAR|CDATE|CDBL|CDEC|CHAIN|CHAR|CHDIR|CINT|CLASS|CLEAR|CLNG|CLOSE|CLS|COBJ|COM|COMMON|CONST|CONTINUE|CSBYTE|CSHORT|CSNG|CSTR|CTYPE|CUINT|CULNG|CUSHORT|DATA|DATE|DECIMAL|DECLARE|DEF(?: FN| SEG|DBL|INT|LNG|SNG|STR)|DEFAULT|DELEGATE|DIM|DIRECTCAST|DO|DOUBLE|ELSE|ELSEIF|END|ENUM|ENVIRON|ERASE|ERROR|EVENT|EXIT|FALSE|FIELD|FILES|FINALLY|FOR(?: EACH)?|FRIEND|FUNCTION|GET|GETTYPE|GETXMLNAMESPACE|GLOBAL|GOSUB|GOTO|HANDLES|IF|IMPLEMENTS|IMPORTS|IN|INHERITS|INPUT|INTEGER|INTERFACE|IOCTL|IS|ISNOT|KEY|KILL|LET|LIB|LIKE|LINE INPUT|LOCATE|LOCK|LONG|LOOP|LSET|ME|MKDIR|MOD|MODULE|MUSTINHERIT|MUSTOVERRIDE|MYBASE|MYCLASS|NAME|NAMESPACE|NARROWING|NEW|NEXT|NOT|NOTHING|NOTINHERITABLE|NOTOVERRIDABLE|OBJECT|OF|OFF|ON(?: COM| ERROR| KEY| TIMER)?|OPEN|OPERATOR|OPTION(?: BASE)?|OPTIONAL|OR|ORELSE|OUT|OVERLOADS|OVERRIDABLE|OVERRIDES|PARAMARRAY|PARTIAL|POKE|PRIVATE|PROPERTY|PROTECTED|PUBLIC|PUT|RAISEEVENT|READ|READONLY|REDIM|REM|REMOVEHANDLER|RESTORE|RESUME|RETURN|RMDIR|RSET|RUN|SBYTE|SELECT(?: CASE)?|SET|SHADOWS|SHARED|SHELL|SHORT|SINGLE|SLEEP|STATIC|STEP|STOP|STRING|STRUCTURE|SUB|SWAP|SYNCLOCK|SYSTEM|THEN|THROW|TIMER|TO|TROFF|TRON|TRUE|TRY|TRYCAST|TYPE|TYPEOF|UINTEGER|ULONG|UNLOCK|UNTIL|USHORT|USING|VIEW PRINT|WAIT|WEND|WHEN|WHILE|WIDENING|WITH|WITHEVENTS|WRITE|WRITEONLY|XOR)|\B(?:#CONST|#ELSE|#ELSEIF|#END|#IF))(?:\$|\b)/i,punctuation:/[,;:(){}]/})}E.exports=I,I.displayName="vbnet",I.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2182.1e53f745.chunk.js b/ydb/core/viewer/monitoring/static/js/2182.1e53f745.chunk.js deleted file mode 100644 index e9decc0cae4d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2182.1e53f745.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2182.1e53f745.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2182],{42182:(e,n,s)=>{s.r(n),s.d(n,{conf:()=>i,language:()=>t});var i={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">",notIn:["string"]}],surroundingPairs:[{open:"(",close:")"},{open:"[",close:"]"},{open:"`",close:"`"}],folding:{markers:{start:new RegExp("^\\s*\x3c!--\\s*#?region\\b.*--\x3e"),end:new RegExp("^\\s*\x3c!--\\s*#?endregion\\b.*--\x3e")}}},t={defaultToken:"",tokenPostfix:".rst",control:/[\\`*_\[\]{}()#+\-\.!]/,escapes:/\\(?:@control)/,empty:["area","base","basefont","br","col","frame","hr","img","input","isindex","link","meta","param"],alphanumerics:/[A-Za-z0-9]/,simpleRefNameWithoutBq:/(?:@alphanumerics[-_+:.]*@alphanumerics)+|(?:@alphanumerics+)/,simpleRefName:/(?:`@phrase`|@simpleRefNameWithoutBq)/,phrase:/@simpleRefNameWithoutBq(?:\s@simpleRefNameWithoutBq)*/,citationName:/[A-Za-z][A-Za-z0-9-_.]*/,blockLiteralStart:/(?:[!"#$%&'()*+,-./:;<=>?@\[\]^_`{|}~]|[\s])/,precedingChars:/(?:[ -:/'"<([{])/,followingChars:/(?:[ -.,:;!?/'")\]}>]|$)/,punctuation:/(=|-|~|`|#|"|\^|\+|\*|:|\.|'|_|\+)/,tokenizer:{root:[[/^(@punctuation{3,}$){1,1}?/,"keyword"],[/^\s*([\*\-+\u2023\u2022]|[a-zA-Z0-9]+\.|\([a-zA-Z0-9]+\)|[a-zA-Z0-9]+\))\s/,"keyword"],[/([ ]::)\s*$/,"keyword","@blankLineOfLiteralBlocks"],[/(::)\s*$/,"keyword","@blankLineOfLiteralBlocks"],{include:"@tables"},{include:"@explicitMarkupBlocks"},{include:"@inlineMarkup"}],explicitMarkupBlocks:[{include:"@citations"},{include:"@footnotes"},[/^(\.\.\s)(@simpleRefName)(::\s)(.*)$/,[{token:"",next:"subsequentLines"},"keyword","",""]],[/^(\.\.)(\s+)(_)(@simpleRefName)(:)(\s+)(.*)/,[{token:"",next:"hyperlinks"},"","","string.link","","","string.link"]],[/^((?:(?:\.\.)(?:\s+))?)(__)(:)(\s+)(.*)/,[{token:"",next:"subsequentLines"},"","","","string.link"]],[/^(__\s+)(.+)/,["","string.link"]],[/^(\.\.)( \|)([^| ]+[^|]*[^| ]*)(\| )(@simpleRefName)(:: .*)/,[{token:"",next:"subsequentLines"},"","string.link","","keyword",""],"@rawBlocks"],[/(\|)([^| ]+[^|]*[^| ]*)(\|_{0,2})/,["","string.link",""]],[/^(\.\.)([ ].*)$/,[{token:"",next:"@comments"},"comment"]]],inlineMarkup:[{include:"@citationsReference"},{include:"@footnotesReference"},[/(@simpleRefName)(_{1,2})/,["string.link",""]],[/(`)([^<`]+\s+)(<)(.*)(>)(`)(_)/,["","string.link","","string.link","","",""]],[/\*\*([^\\*]|\*(?!\*))+\*\*/,"strong"],[/\*[^*]+\*/,"emphasis"],[/(``)((?:[^`]|\`(?!`))+)(``)/,["","keyword",""]],[/(__\s+)(.+)/,["","keyword"]],[/(:)((?:@simpleRefNameWithoutBq)?)(:`)([^`]+)(`)/,["","keyword","","",""]],[/(`)([^`]+)(`:)((?:@simpleRefNameWithoutBq)?)(:)/,["","","","keyword",""]],[/(`)([^`]+)(`)/,""],[/(_`)(@phrase)(`)/,["","string.link",""]]],citations:[[/^(\.\.\s+\[)((?:@citationName))(\]\s+)(.*)/,[{token:"",next:"@subsequentLines"},"string.link","",""]]],citationsReference:[[/(\[)(@citationName)(\]_)/,["","string.link",""]]],footnotes:[[/^(\.\.\s+\[)((?:[0-9]+))(\]\s+.*)/,[{token:"",next:"@subsequentLines"},"string.link",""]],[/^(\.\.\s+\[)((?:#@simpleRefName?))(\]\s+)(.*)/,[{token:"",next:"@subsequentLines"},"string.link","",""]],[/^(\.\.\s+\[)((?:\*))(\]\s+)(.*)/,[{token:"",next:"@subsequentLines"},"string.link","",""]]],footnotesReference:[[/(\[)([0-9]+)(\])(_)/,["","string.link","",""]],[/(\[)(#@simpleRefName?)(\])(_)/,["","string.link","",""]],[/(\[)(\*)(\])(_)/,["","string.link","",""]]],blankLineOfLiteralBlocks:[[/^$/,"","@subsequentLinesOfLiteralBlocks"],[/^.*$/,"","@pop"]],subsequentLinesOfLiteralBlocks:[[/(@blockLiteralStart+)(.*)/,["keyword",""]],[/^(?!blockLiteralStart)/,"","@popall"]],subsequentLines:[[/^[\s]+.*/,""],[/^(?!\s)/,"","@pop"]],hyperlinks:[[/^[\s]+.*/,"string.link"],[/^(?!\s)/,"","@pop"]],comments:[[/^[\s]+.*/,"comment"],[/^(?!\s)/,"","@pop"]],tables:[[/\+-[+-]+/,"keyword"],[/\+=[+=]+/,"keyword"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/21956.3e818e6c.chunk.js b/ydb/core/viewer/monitoring/static/js/21956.3e818e6c.chunk.js new file mode 100644 index 000000000000..bc76351b8c89 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/21956.3e818e6c.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[21956],{21956:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"kn",weekdays:"\u0cad\u0cbe\u0ca8\u0cc1\u0cb5\u0cbe\u0cb0_\u0cb8\u0cc6\u0cc2\u0cd5\u0cae\u0cb5\u0cbe\u0cb0_\u0cae\u0c82\u0c97\u0cb3\u0cb5\u0cbe\u0cb0_\u0cac\u0cc1\u0ca7\u0cb5\u0cbe\u0cb0_\u0c97\u0cc1\u0cb0\u0cc1\u0cb5\u0cbe\u0cb0_\u0cb6\u0cc1\u0c95\u0ccd\u0cb0\u0cb5\u0cbe\u0cb0_\u0cb6\u0ca8\u0cbf\u0cb5\u0cbe\u0cb0".split("_"),months:"\u0c9c\u0ca8\u0cb5\u0cb0\u0cbf_\u0cab\u0cc6\u0cac\u0ccd\u0cb0\u0cb5\u0cb0\u0cbf_\u0cae\u0cbe\u0cb0\u0ccd\u0c9a\u0ccd_\u0c8f\u0caa\u0ccd\u0cb0\u0cbf\u0cb2\u0ccd_\u0cae\u0cc6\u0cd5_\u0c9c\u0cc2\u0ca8\u0ccd_\u0c9c\u0cc1\u0cb2\u0cc6\u0cd6_\u0c86\u0c97\u0cb8\u0ccd\u0c9f\u0ccd_\u0cb8\u0cc6\u0caa\u0ccd\u0c9f\u0cc6\u0c82\u0cac\u0cb0\u0ccd_\u0c85\u0c95\u0ccd\u0c9f\u0cc6\u0cc2\u0cd5\u0cac\u0cb0\u0ccd_\u0ca8\u0cb5\u0cc6\u0c82\u0cac\u0cb0\u0ccd_\u0ca1\u0cbf\u0cb8\u0cc6\u0c82\u0cac\u0cb0\u0ccd".split("_"),weekdaysShort:"\u0cad\u0cbe\u0ca8\u0cc1_\u0cb8\u0cc6\u0cc2\u0cd5\u0cae_\u0cae\u0c82\u0c97\u0cb3_\u0cac\u0cc1\u0ca7_\u0c97\u0cc1\u0cb0\u0cc1_\u0cb6\u0cc1\u0c95\u0ccd\u0cb0_\u0cb6\u0ca8\u0cbf".split("_"),monthsShort:"\u0c9c\u0ca8_\u0cab\u0cc6\u0cac\u0ccd\u0cb0_\u0cae\u0cbe\u0cb0\u0ccd\u0c9a\u0ccd_\u0c8f\u0caa\u0ccd\u0cb0\u0cbf\u0cb2\u0ccd_\u0cae\u0cc6\u0cd5_\u0c9c\u0cc2\u0ca8\u0ccd_\u0c9c\u0cc1\u0cb2\u0cc6\u0cd6_\u0c86\u0c97\u0cb8\u0ccd\u0c9f\u0ccd_\u0cb8\u0cc6\u0caa\u0ccd\u0c9f\u0cc6\u0c82_\u0c85\u0c95\u0ccd\u0c9f\u0cc6\u0cc2\u0cd5_\u0ca8\u0cb5\u0cc6\u0c82_\u0ca1\u0cbf\u0cb8\u0cc6\u0c82".split("_"),weekdaysMin:"\u0cad\u0cbe_\u0cb8\u0cc6\u0cc2\u0cd5_\u0cae\u0c82_\u0cac\u0cc1_\u0c97\u0cc1_\u0cb6\u0cc1_\u0cb6".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm",LTS:"A h:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm",LLLL:"dddd, D MMMM YYYY, A h:mm"},relativeTime:{future:"%s \u0ca8\u0c82\u0ca4\u0cb0",past:"%s \u0cb9\u0cbf\u0c82\u0ca6\u0cc6",s:"\u0c95\u0cc6\u0cb2\u0cb5\u0cc1 \u0c95\u0ccd\u0cb7\u0ca3\u0c97\u0cb3\u0cc1",m:"\u0c92\u0c82\u0ca6\u0cc1 \u0ca8\u0cbf\u0cae\u0cbf\u0cb7",mm:"%d \u0ca8\u0cbf\u0cae\u0cbf\u0cb7",h:"\u0c92\u0c82\u0ca6\u0cc1 \u0c97\u0c82\u0c9f\u0cc6",hh:"%d \u0c97\u0c82\u0c9f\u0cc6",d:"\u0c92\u0c82\u0ca6\u0cc1 \u0ca6\u0cbf\u0ca8",dd:"%d \u0ca6\u0cbf\u0ca8",M:"\u0c92\u0c82\u0ca6\u0cc1 \u0ca4\u0cbf\u0c82\u0c97\u0cb3\u0cc1",MM:"%d \u0ca4\u0cbf\u0c82\u0c97\u0cb3\u0cc1",y:"\u0c92\u0c82\u0ca6\u0cc1 \u0cb5\u0cb0\u0ccd\u0cb7",yy:"%d \u0cb5\u0cb0\u0ccd\u0cb7"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/21989.76579159.chunk.js b/ydb/core/viewer/monitoring/static/js/21989.76579159.chunk.js new file mode 100644 index 000000000000..1f17677fa5e5 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/21989.76579159.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[21989],{21989:(e,t,r)=>{r.d(t,{default:()=>s});var n=r(38766);const s=r.n(n)()},38766:e=>{function t(e){e.languages.clojure={comment:{pattern:/;.*/,greedy:!0},string:{pattern:/"(?:[^"\\]|\\.)*"/,greedy:!0},char:/\\\w+/,symbol:{pattern:/(^|[\s()\[\]{},])::?[\w*+!?'<>=/.-]+/,lookbehind:!0},keyword:{pattern:/(\()(?:-|->|->>|\.|\.\.|\*|\/|\+|<|<=|=|==|>|>=|accessor|agent|agent-errors|aget|alength|all-ns|alter|and|append-child|apply|array-map|aset|aset-boolean|aset-byte|aset-char|aset-double|aset-float|aset-int|aset-long|aset-short|assert|assoc|await|await-for|bean|binding|bit-and|bit-not|bit-or|bit-shift-left|bit-shift-right|bit-xor|boolean|branch\?|butlast|byte|cast|char|children|class|clear-agent-errors|comment|commute|comp|comparator|complement|concat|cond|conj|cons|constantly|construct-proxy|contains\?|count|create-ns|create-struct|cycle|dec|declare|def|def-|definline|definterface|defmacro|defmethod|defmulti|defn|defn-|defonce|defproject|defprotocol|defrecord|defstruct|deftype|deref|difference|disj|dissoc|distinct|do|doall|doc|dorun|doseq|dosync|dotimes|doto|double|down|drop|drop-while|edit|end\?|ensure|eval|every\?|false\?|ffirst|file-seq|filter|find|find-doc|find-ns|find-var|first|float|flush|fn|fnseq|for|frest|gensym|get|get-proxy-class|hash-map|hash-set|identical\?|identity|if|if-let|if-not|import|in-ns|inc|index|insert-child|insert-left|insert-right|inspect-table|inspect-tree|instance\?|int|interleave|intersection|into|into-array|iterate|join|key|keys|keyword|keyword\?|last|lazy-cat|lazy-cons|left|lefts|let|line-seq|list|list\*|load|load-file|locking|long|loop|macroexpand|macroexpand-1|make-array|make-node|map|map-invert|map\?|mapcat|max|max-key|memfn|merge|merge-with|meta|min|min-key|monitor-enter|name|namespace|neg\?|new|newline|next|nil\?|node|not|not-any\?|not-every\?|not=|ns|ns-imports|ns-interns|ns-map|ns-name|ns-publics|ns-refers|ns-resolve|ns-unmap|nth|nthrest|or|parse|partial|path|peek|pop|pos\?|pr|pr-str|print|print-str|println|println-str|prn|prn-str|project|proxy|proxy-mappings|quot|quote|rand|rand-int|range|re-find|re-groups|re-matcher|re-matches|re-pattern|re-seq|read|read-line|recur|reduce|ref|ref-set|refer|rem|remove|remove-method|remove-ns|rename|rename-keys|repeat|replace|replicate|resolve|rest|resultset-seq|reverse|rfirst|right|rights|root|rrest|rseq|second|select|select-keys|send|send-off|seq|seq-zip|seq\?|set|set!|short|slurp|some|sort|sort-by|sorted-map|sorted-map-by|sorted-set|special-symbol\?|split-at|split-with|str|string\?|struct|struct-map|subs|subvec|symbol|symbol\?|sync|take|take-nth|take-while|test|throw|time|to-array|to-array-2d|tree-seq|true\?|try|union|up|update-proxy|val|vals|var|var-get|var-set|var\?|vector|vector-zip|vector\?|when|when-first|when-let|when-not|with-local-vars|with-meta|with-open|with-out-str|xml-seq|xml-zip|zero\?|zipmap|zipper)(?=[\s)]|$)/,lookbehind:!0},boolean:/\b(?:false|nil|true)\b/,number:{pattern:/(^|[^\w$@])(?:\d+(?:[/.]\d+)?(?:e[+-]?\d+)?|0x[a-f0-9]+|[1-9]\d?r[a-z0-9]+)[lmn]?(?![\w$@])/i,lookbehind:!0},function:{pattern:/((?:^|[^'])\()[\w*+!?'<>=/.-]+(?=[\s)]|$)/,lookbehind:!0},operator:/[#@^`~]/,punctuation:/[{}\[\](),]/}}e.exports=t,t.displayName="clojure",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/21996.6a6996bf.chunk.js b/ydb/core/viewer/monitoring/static/js/21996.6a6996bf.chunk.js new file mode 100644 index 000000000000..92c827cb7f4f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/21996.6a6996bf.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[21996],{21996:(e,t,a)=>{a.d(t,{default:()=>i});var n=a(33423);const i=a.n(n)()},33423:e=>{function t(e){!function(e){var t=/(?:"(?:""|[^"])*"(?!")|'(?:''|[^'])*'(?!'))/.source,a=/\b(?:\d[\da-f]*x|\d+(?:\.\d+)?(?:e[+-]?\d+)?)\b/i,n={pattern:RegExp(t+"[bx]"),alias:"number"},i={pattern:/&[a-z_]\w*/i},s={pattern:/((?:^|\s|=|\())%(?:ABORT|BY|CMS|COPY|DISPLAY|DO|ELSE|END|EVAL|GLOBAL|GO|GOTO|IF|INC|INCLUDE|INDEX|INPUT|KTRIM|LENGTH|LET|LIST|LOCAL|PUT|QKTRIM|QSCAN|QSUBSTR|QSYSFUNC|QUPCASE|RETURN|RUN|SCAN|SUBSTR|SUPERQ|SYMDEL|SYMEXIST|SYMGLOBL|SYMLOCAL|SYSCALL|SYSEVALF|SYSEXEC|SYSFUNC|SYSGET|SYSRPUT|THEN|TO|TSO|UNQUOTE|UNTIL|UPCASE|WHILE|WINDOW)\b/i,lookbehind:!0,alias:"keyword"},r={pattern:/(^|\s)(?:proc\s+\w+|data(?!=)|quit|run)\b/i,alias:"keyword",lookbehind:!0},o=[/\/\*[\s\S]*?\*\//,{pattern:/(^[ \t]*|;\s*)\*[^;]*;/m,lookbehind:!0}],l={pattern:RegExp(t),greedy:!0},c=/[$%@.(){}\[\];,\\]/,d={pattern:/%?\b\w+(?=\()/,alias:"keyword"},u={function:d,"arg-value":{pattern:/(=\s*)[A-Z\.]+/i,lookbehind:!0},operator:/=/,"macro-variable":i,arg:{pattern:/[A-Z]+/i,alias:"keyword"},number:a,"numeric-constant":n,punctuation:c,string:l},p={pattern:/\b(?:format|put)\b=?[\w'$.]+/i,inside:{keyword:/^(?:format|put)(?==)/i,equals:/=/,format:{pattern:/(?:\w|\$\d)+\.\d?/,alias:"number"}}},m={pattern:/\b(?:format|put)\s+[\w']+(?:\s+[$.\w]+)+(?=;)/i,inside:{keyword:/^(?:format|put)/i,format:{pattern:/[\w$]+\.\d?/,alias:"number"}}},b={pattern:/((?:^|\s)=?)(?:catname|checkpoint execute_always|dm|endsas|filename|footnote|%include|libname|%list|lock|missing|options|page|resetline|%run|sasfile|skip|sysecho|title\d?)\b/i,lookbehind:!0,alias:"keyword"},g={pattern:/(^|\s)(?:submit(?:\s+(?:load|norun|parseonly))?|endsubmit)\b/i,lookbehind:!0,alias:"keyword"},k=/aStore|accessControl|aggregation|audio|autotune|bayesianNetClassifier|bioMedImage|boolRule|builtins|cardinality|cdm|clustering|conditionalRandomFields|configuration|copula|countreg|dataDiscovery|dataPreprocess|dataSciencePilot|dataStep|decisionTree|deduplication|deepLearn|deepNeural|deepRnn|ds2|ecm|entityRes|espCluster|explainModel|factmac|fastKnn|fcmpact|fedSql|freqTab|gVarCluster|gam|gleam|graphSemiSupLearn|hiddenMarkovModel|hyperGroup|ica|image|iml|kernalPca|langModel|ldaTopic|loadStreams|mbc|mixed|mlTools|modelPublishing|network|neuralNet|nmf|nonParametricBayes|nonlinear|optNetwork|optimization|panel|pca|percentile|phreg|pls|qkb|qlim|quantreg|recommend|regression|reinforcementLearn|robustPca|ruleMining|sampling|sandwich|sccasl|search(?:Analytics)?|sentimentAnalysis|sequence|session(?:Prop)?|severity|simSystem|simple|smartData|sparkEmbeddedProcess|sparseML|spatialreg|spc|stabilityMonitoring|svDataDescription|svm|table|text(?:Filters|Frequency|Mining|Parse|Rule(?:Develop|Score)|Topic|Util)|timeData|transpose|tsInfo|tsReconcile|uniTimeSeries|varReduce/.source,y={pattern:RegExp(/(^|\s)(?:action\s+)?(?:)\.[a-z]+\b[^;]+/.source.replace(//g,(function(){return k})),"i"),lookbehind:!0,inside:{keyword:RegExp(/(?:)\.[a-z]+\b/.source.replace(//g,(function(){return k})),"i"),action:{pattern:/(?:action)/i,alias:"keyword"},comment:o,function:d,"arg-value":u["arg-value"],operator:u.operator,argument:u.arg,number:a,"numeric-constant":n,punctuation:c,string:l}},w={pattern:/((?:^|\s)=?)(?:after|analysis|and|array|barchart|barwidth|begingraph|by|call|cas|cbarline|cfill|class(?:lev)?|close|column|computed?|contains|continue|data(?==)|define|delete|describe|document|do\s+over|do|dol|drop|dul|else|end(?:comp|source)?|entryTitle|eval(?:uate)?|exec(?:ute)?|exit|file(?:name)?|fill(?:attrs)?|flist|fnc|function(?:list)?|global|goto|group(?:by)?|headline|headskip|histogram|if|infile|keep|keylabel|keyword|label|layout|leave|legendlabel|length|libname|loadactionset|merge|midpoints|_?null_|name|noobs|nowd|ods|options|or|otherwise|out(?:put)?|over(?:lay)?|plot|print|put|raise|ranexp|rannor|rbreak|retain|return|select|session|sessref|set|source|statgraph|sum|summarize|table|temp|terminate|then\s+do|then|title\d?|to|var|when|where|xaxisopts|y2axisopts|yaxisopts)\b/i,lookbehind:!0};e.languages.sas={datalines:{pattern:/^([ \t]*)(?:cards|(?:data)?lines);[\s\S]+?^[ \t]*;/im,lookbehind:!0,alias:"string",inside:{keyword:{pattern:/^(?:cards|(?:data)?lines)/i},punctuation:/;/}},"proc-sql":{pattern:/(^proc\s+(?:fed)?sql(?:\s+[\w|=]+)?;)[\s\S]+?(?=^(?:proc\s+\w+|data|quit|run);|(?![\s\S]))/im,lookbehind:!0,inside:{sql:{pattern:RegExp(/^[ \t]*(?:select|alter\s+table|(?:create|describe|drop)\s+(?:index|table(?:\s+constraints)?|view)|create\s+unique\s+index|insert\s+into|update)(?:|[^;"'])+;/.source.replace(//g,(function(){return t})),"im"),alias:"language-sql",inside:e.languages.sql},"global-statements":b,"sql-statements":{pattern:/(^|\s)(?:disconnect\s+from|begin|commit|exec(?:ute)?|reset|rollback|validate)\b/i,lookbehind:!0,alias:"keyword"},number:a,"numeric-constant":n,punctuation:c,string:l}},"proc-groovy":{pattern:/(^proc\s+groovy(?:\s+[\w|=]+)?;)[\s\S]+?(?=^(?:proc\s+\w+|data|quit|run);|(?![\s\S]))/im,lookbehind:!0,inside:{comment:o,groovy:{pattern:RegExp(/(^[ \t]*submit(?:\s+(?:load|norun|parseonly))?)(?:|[^"'])+?(?=endsubmit;)/.source.replace(//g,(function(){return t})),"im"),lookbehind:!0,alias:"language-groovy",inside:e.languages.groovy},keyword:w,"submit-statement":g,"global-statements":b,number:a,"numeric-constant":n,punctuation:c,string:l}},"proc-lua":{pattern:/(^proc\s+lua(?:\s+[\w|=]+)?;)[\s\S]+?(?=^(?:proc\s+\w+|data|quit|run);|(?![\s\S]))/im,lookbehind:!0,inside:{comment:o,lua:{pattern:RegExp(/(^[ \t]*submit(?:\s+(?:load|norun|parseonly))?)(?:|[^"'])+?(?=endsubmit;)/.source.replace(//g,(function(){return t})),"im"),lookbehind:!0,alias:"language-lua",inside:e.languages.lua},keyword:w,"submit-statement":g,"global-statements":b,number:a,"numeric-constant":n,punctuation:c,string:l}},"proc-cas":{pattern:/(^proc\s+cas(?:\s+[\w|=]+)?;)[\s\S]+?(?=^(?:proc\s+\w+|quit|data);|(?![\s\S]))/im,lookbehind:!0,inside:{comment:o,"statement-var":{pattern:/((?:^|\s)=?)saveresult\s[^;]+/im,lookbehind:!0,inside:{statement:{pattern:/^saveresult\s+\S+/i,inside:{keyword:/^(?:saveresult)/i}},rest:u}},"cas-actions":y,statement:{pattern:/((?:^|\s)=?)(?:default|(?:un)?set|on|output|upload)[^;]+/im,lookbehind:!0,inside:u},step:r,keyword:w,function:d,format:p,altformat:m,"global-statements":b,number:a,"numeric-constant":n,punctuation:c,string:l}},"proc-args":{pattern:RegExp(/(^proc\s+\w+\s+)(?!\s)(?:[^;"']|)+;/.source.replace(//g,(function(){return t})),"im"),lookbehind:!0,inside:u},"macro-keyword":s,"macro-variable":i,"macro-string-functions":{pattern:/((?:^|\s|=))%(?:BQUOTE|NRBQUOTE|NRQUOTE|NRSTR|QUOTE|STR)\(.*?(?:[^%]\))/i,lookbehind:!0,inside:{function:{pattern:/%(?:BQUOTE|NRBQUOTE|NRQUOTE|NRSTR|QUOTE|STR)/i,alias:"keyword"},"macro-keyword":s,"macro-variable":i,"escaped-char":{pattern:/%['"()<>=\xac^~;,#]/},punctuation:c}},"macro-declaration":{pattern:/^%macro[^;]+(?=;)/im,inside:{keyword:/%macro/i}},"macro-end":{pattern:/^%mend[^;]+(?=;)/im,inside:{keyword:/%mend/i}},macro:{pattern:/%_\w+(?=\()/,alias:"keyword"},input:{pattern:/\binput\s[-\w\s/*.$&]+;/i,inside:{input:{alias:"keyword",pattern:/^input/i},comment:o,number:a,"numeric-constant":n}},"options-args":{pattern:/(^options)[-'"|/\\<>*+=:()\w\s]*(?=;)/im,lookbehind:!0,inside:u},"cas-actions":y,comment:o,function:d,format:p,altformat:m,"numeric-constant":n,datetime:{pattern:RegExp(t+"(?:dt?|t)"),alias:"number"},string:l,step:r,keyword:w,"operator-keyword":{pattern:/\b(?:eq|ge|gt|in|le|lt|ne|not)\b/i,alias:"operator"},number:a,operator:/\*\*?|\|\|?|!!?|\xa6\xa6?|<[>=]?|>[<=]?|[-+\/=&]|[~\xac^]=?/,punctuation:c}}(e)}e.exports=t,t.displayName="sas",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/221.b740df48.chunk.js b/ydb/core/viewer/monitoring/static/js/221.b740df48.chunk.js deleted file mode 100644 index 5c65bfddd22a..000000000000 --- a/ydb/core/viewer/monitoring/static/js/221.b740df48.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[221],{60221:function(_,e,d){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var d=e(_),Y={name:"zh-tw",weekdays:"\u661f\u671f\u65e5_\u661f\u671f\u4e00_\u661f\u671f\u4e8c_\u661f\u671f\u4e09_\u661f\u671f\u56db_\u661f\u671f\u4e94_\u661f\u671f\u516d".split("_"),weekdaysShort:"\u9031\u65e5_\u9031\u4e00_\u9031\u4e8c_\u9031\u4e09_\u9031\u56db_\u9031\u4e94_\u9031\u516d".split("_"),weekdaysMin:"\u65e5_\u4e00_\u4e8c_\u4e09_\u56db_\u4e94_\u516d".split("_"),months:"\u4e00\u6708_\u4e8c\u6708_\u4e09\u6708_\u56db\u6708_\u4e94\u6708_\u516d\u6708_\u4e03\u6708_\u516b\u6708_\u4e5d\u6708_\u5341\u6708_\u5341\u4e00\u6708_\u5341\u4e8c\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),ordinal:function(_,e){return"W"===e?_+"\u9031":_+"\u65e5"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5 HH:mm",LLLL:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm",l:"YYYY/M/D",ll:"YYYY\u5e74M\u6708D\u65e5",lll:"YYYY\u5e74M\u6708D\u65e5 HH:mm",llll:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm"},relativeTime:{future:"%s\u5167",past:"%s\u524d",s:"\u5e7e\u79d2",m:"1 \u5206\u9418",mm:"%d \u5206\u9418",h:"1 \u5c0f\u6642",hh:"%d \u5c0f\u6642",d:"1 \u5929",dd:"%d \u5929",M:"1 \u500b\u6708",MM:"%d \u500b\u6708",y:"1 \u5e74",yy:"%d \u5e74"},meridiem:function(_,e){var d=100*_+e;return d<600?"\u51cc\u6668":d<900?"\u65e9\u4e0a":d<1100?"\u4e0a\u5348":d<1300?"\u4e2d\u5348":d<1800?"\u4e0b\u5348":"\u665a\u4e0a"}};return d.default.locale(Y,null,!0),Y}(d(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/22372.9c5be99f.chunk.js b/ydb/core/viewer/monitoring/static/js/22372.9c5be99f.chunk.js new file mode 100644 index 000000000000..70d7c9296574 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/22372.9c5be99f.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 22372.9c5be99f.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[22372],{22372:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>d,language:()=>f});var r,s,i=n(80781),o=Object.defineProperty,l=Object.getOwnPropertyDescriptor,a=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,p=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let s of a(t))c.call(e,s)||s===n||o(e,s,{get:()=>t[s],enumerable:!(r=l(t,s))||r.enumerable});return e},g={};p(g,r=i,"default"),s&&p(s,r,"default");var d={comments:{lineComment:"#",blockComment:["'''","'''"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],onEnterRules:[{beforeText:new RegExp("^\\s*(?:def|class|for|if|elif|else|while|try|with|finally|except|async|match|case).*?:\\s*$"),action:{indentAction:g.languages.IndentAction.Indent}}],folding:{offSide:!0,markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},f={defaultToken:"",tokenPostfix:".python",keywords:["False","None","True","_","and","as","assert","async","await","break","case","class","continue","def","del","elif","else","except","exec","finally","for","from","global","if","import","in","is","lambda","match","nonlocal","not","or","pass","print","raise","return","try","type","while","with","yield","int","float","long","complex","hex","abs","all","any","apply","basestring","bin","bool","buffer","bytearray","callable","chr","classmethod","cmp","coerce","compile","complex","delattr","dict","dir","divmod","enumerate","eval","execfile","file","filter","format","frozenset","getattr","globals","hasattr","hash","help","id","input","intern","isinstance","issubclass","iter","len","locals","list","map","max","memoryview","min","next","object","oct","open","ord","pow","print","property","reversed","range","raw_input","reduce","reload","repr","reversed","round","self","set","setattr","slice","sorted","staticmethod","str","sum","super","tuple","type","unichr","unicode","vars","xrange","zip","__dict__","__methods__","__members__","__class__","__bases__","__name__","__mro__","__subclasses__","__init__","__import__"],brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"}],tokenizer:{root:[{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},[/[,:;]/,"delimiter"],[/[{}\[\]()]/,"@brackets"],[/@[a-zA-Z_]\w*/,"tag"],[/[a-zA-Z_]\w*/,{cases:{"@keywords":"keyword","@default":"identifier"}}]],whitespace:[[/\s+/,"white"],[/(^#.*$)/,"comment"],[/'''/,"string","@endDocString"],[/"""/,"string","@endDblDocString"]],endDocString:[[/[^']+/,"string"],[/\\'/,"string"],[/'''/,"string","@popall"],[/'/,"string"]],endDblDocString:[[/[^"]+/,"string"],[/\\"/,"string"],[/"""/,"string","@popall"],[/"/,"string"]],numbers:[[/-?0x([abcdef]|[ABCDEF]|\d)+[lL]?/,"number.hex"],[/-?(\d*\.)?\d+([eE][+\-]?\d+)?[jJ]?[lL]?/,"number"]],strings:[[/'$/,"string.escape","@popall"],[/f'{1,3}/,"string.escape","@fStringBody"],[/'/,"string.escape","@stringBody"],[/"$/,"string.escape","@popall"],[/f"{1,3}/,"string.escape","@fDblStringBody"],[/"/,"string.escape","@dblStringBody"]],fStringBody:[[/[^\\'\{\}]+$/,"string","@popall"],[/[^\\'\{\}]+/,"string"],[/\{[^\}':!=]+/,"identifier","@fStringDetail"],[/\\./,"string"],[/'/,"string.escape","@popall"],[/\\$/,"string"]],stringBody:[[/[^\\']+$/,"string","@popall"],[/[^\\']+/,"string"],[/\\./,"string"],[/'/,"string.escape","@popall"],[/\\$/,"string"]],fDblStringBody:[[/[^\\"\{\}]+$/,"string","@popall"],[/[^\\"\{\}]+/,"string"],[/\{[^\}':!=]+/,"identifier","@fStringDetail"],[/\\./,"string"],[/"/,"string.escape","@popall"],[/\\$/,"string"]],dblStringBody:[[/[^\\"]+$/,"string","@popall"],[/[^\\"]+/,"string"],[/\\./,"string"],[/"/,"string.escape","@popall"],[/\\$/,"string"]],fStringDetail:[[/[:][^}]+/,"string"],[/[!][ars]/,"string"],[/=/,"string"],[/\}/,"identifier","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2182.1e53f745.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/22372.9c5be99f.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2182.1e53f745.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/22372.9c5be99f.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/225.cf362439.chunk.js b/ydb/core/viewer/monitoring/static/js/225.cf362439.chunk.js deleted file mode 100644 index f2bbb1e6b2f8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/225.cf362439.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 225.cf362439.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[225],{70225:(e,t,n)=>{n.r(t),n.d(t,{CompletionAdapter:()=>Wt,DefinitionAdapter:()=>Zt,DiagnosticsAdapter:()=>Ot,DocumentColorAdapter:()=>ln,DocumentFormattingEditProvider:()=>un,DocumentHighlightAdapter:()=>Jt,DocumentLinkAdapter:()=>sn,DocumentRangeFormattingEditProvider:()=>cn,DocumentSymbolAdapter:()=>rn,FoldingRangeAdapter:()=>gn,HoverAdapter:()=>qt,ReferenceAdapter:()=>tn,RenameAdapter:()=>nn,SelectionRangeAdapter:()=>fn,WorkerManager:()=>Nt,fromPosition:()=>Ht,fromRange:()=>Xt,setupMode:()=>hn,toRange:()=>zt,toTextEdit:()=>Bt});var r,i,o=n(80781),a=Object.defineProperty,s=Object.getOwnPropertyDescriptor,u=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,d=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of u(t))c.call(e,i)||i===n||a(e,i,{get:()=>t[i],enumerable:!(r=s(t,i))||r.enumerable});return e},l={};d(l,r=o,"default"),i&&d(i,r,"default");var g,f,h,p,m,v,b,_,k,y,w,x,I,E,C,A,S,R,L,T,M,D,P,F,j,N,U,V,O,K,W,H,X,z,$,B,q,Q,G,J,Y,Z,ee,te,ne,re,ie,oe,ae,se,ue,ce,de,le,ge,fe,he,pe,me,ve,be,_e,ke,ye,we,xe,Ie,Ee,Ce,Ae,Se,Re,Le,Te,Me,De,Pe,Fe,je,Ne,Ue,Ve,Oe,Ke,We,He,Xe,ze,$e,Be,qe,Qe,Ge,Je,Ye,Ze,et,tt,nt,rt,it,ot,at,st,ut,ct,dt,lt,gt,ft,ht,pt,mt,vt,bt,_t,kt,yt,wt,xt,It,Et,Ct,At,St,Rt,Lt,Tt,Mt,Dt,Pt,Ft,jt,Nt=class{constructor(e){this._defaults=e,this._worker=null,this._client=null,this._idleCheckInterval=window.setInterval((()=>this._checkIfIdle()),3e4),this._lastUsedTime=0,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker()))}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}dispose(){clearInterval(this._idleCheckInterval),this._configChangeListener.dispose(),this._stopWorker()}_checkIfIdle(){if(!this._worker)return;Date.now()-this._lastUsedTime>12e4&&this._stopWorker()}_getClient(){return this._lastUsedTime=Date.now(),this._client||(this._worker=l.editor.createWebWorker({moduleId:"vs/language/css/cssWorker",label:this._defaults.languageId,createData:{options:this._defaults.options,languageId:this._defaults.languageId}}),this._client=this._worker.getProxy()),this._client}getLanguageServiceWorker(...e){let t;return this._getClient().then((e=>{t=e})).then((t=>{if(this._worker)return this._worker.withSyncedResources(e)})).then((e=>t))}};(g||(g={})).is=function(e){return"string"===typeof e},(f||(f={})).is=function(e){return"string"===typeof e},(p=h||(h={})).MIN_VALUE=-2147483648,p.MAX_VALUE=2147483647,p.is=function(e){return"number"===typeof e&&p.MIN_VALUE<=e&&e<=p.MAX_VALUE},(v=m||(m={})).MIN_VALUE=0,v.MAX_VALUE=2147483647,v.is=function(e){return"number"===typeof e&&v.MIN_VALUE<=e&&e<=v.MAX_VALUE},(_=b||(b={})).create=function(e,t){return e===Number.MAX_VALUE&&(e=m.MAX_VALUE),t===Number.MAX_VALUE&&(t=m.MAX_VALUE),{line:e,character:t}},_.is=function(e){let t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.line)&&Ut.uinteger(t.character)},(y=k||(k={})).create=function(e,t,n,r){if(Ut.uinteger(e)&&Ut.uinteger(t)&&Ut.uinteger(n)&&Ut.uinteger(r))return{start:b.create(e,t),end:b.create(n,r)};if(b.is(e)&&b.is(t))return{start:e,end:t};throw new Error(`Range#create called with invalid arguments[${e}, ${t}, ${n}, ${r}]`)},y.is=function(e){let t=e;return Ut.objectLiteral(t)&&b.is(t.start)&&b.is(t.end)},(x=w||(w={})).create=function(e,t){return{uri:e,range:t}},x.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(Ut.string(t.uri)||Ut.undefined(t.uri))},(E=I||(I={})).create=function(e,t,n,r){return{targetUri:e,targetRange:t,targetSelectionRange:n,originSelectionRange:r}},E.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.targetRange)&&Ut.string(t.targetUri)&&k.is(t.targetSelectionRange)&&(k.is(t.originSelectionRange)||Ut.undefined(t.originSelectionRange))},(A=C||(C={})).create=function(e,t,n,r){return{red:e,green:t,blue:n,alpha:r}},A.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.numberRange(t.red,0,1)&&Ut.numberRange(t.green,0,1)&&Ut.numberRange(t.blue,0,1)&&Ut.numberRange(t.alpha,0,1)},(R=S||(S={})).create=function(e,t){return{range:e,color:t}},R.is=function(e){const t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&C.is(t.color)},(T=L||(L={})).create=function(e,t,n){return{label:e,textEdit:t,additionalTextEdits:n}},T.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.undefined(t.textEdit)||B.is(t))&&(Ut.undefined(t.additionalTextEdits)||Ut.typedArray(t.additionalTextEdits,B.is))},(D=M||(M={})).Comment="comment",D.Imports="imports",D.Region="region",(F=P||(P={})).create=function(e,t,n,r,i,o){const a={startLine:e,endLine:t};return Ut.defined(n)&&(a.startCharacter=n),Ut.defined(r)&&(a.endCharacter=r),Ut.defined(i)&&(a.kind=i),Ut.defined(o)&&(a.collapsedText=o),a},F.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.startLine)&&Ut.uinteger(t.startLine)&&(Ut.undefined(t.startCharacter)||Ut.uinteger(t.startCharacter))&&(Ut.undefined(t.endCharacter)||Ut.uinteger(t.endCharacter))&&(Ut.undefined(t.kind)||Ut.string(t.kind))},(N=j||(j={})).create=function(e,t){return{location:e,message:t}},N.is=function(e){let t=e;return Ut.defined(t)&&w.is(t.location)&&Ut.string(t.message)},(V=U||(U={})).Error=1,V.Warning=2,V.Information=3,V.Hint=4,(K=O||(O={})).Unnecessary=1,K.Deprecated=2,(W||(W={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.href)},(X=H||(H={})).create=function(e,t,n,r,i,o){let a={range:e,message:t};return Ut.defined(n)&&(a.severity=n),Ut.defined(r)&&(a.code=r),Ut.defined(i)&&(a.source=i),Ut.defined(o)&&(a.relatedInformation=o),a},X.is=function(e){var t;let n=e;return Ut.defined(n)&&k.is(n.range)&&Ut.string(n.message)&&(Ut.number(n.severity)||Ut.undefined(n.severity))&&(Ut.integer(n.code)||Ut.string(n.code)||Ut.undefined(n.code))&&(Ut.undefined(n.codeDescription)||Ut.string(null===(t=n.codeDescription)||void 0===t?void 0:t.href))&&(Ut.string(n.source)||Ut.undefined(n.source))&&(Ut.undefined(n.relatedInformation)||Ut.typedArray(n.relatedInformation,j.is))},($=z||(z={})).create=function(e,t,...n){let r={title:e,command:t};return Ut.defined(n)&&n.length>0&&(r.arguments=n),r},$.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.title)&&Ut.string(t.command)},(q=B||(B={})).replace=function(e,t){return{range:e,newText:t}},q.insert=function(e,t){return{range:{start:e,end:e},newText:t}},q.del=function(e){return{range:e,newText:""}},q.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.newText)&&k.is(t.range)},(G=Q||(Q={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},G.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(Ut.string(t.description)||void 0===t.description)},(J||(J={})).is=function(e){const t=e;return Ut.string(t)},(Z=Y||(Y={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},Z.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},Z.del=function(e,t){return{range:e,newText:"",annotationId:t}},Z.is=function(e){const t=e;return B.is(t)&&(Q.is(t.annotationId)||J.is(t.annotationId))},(te=ee||(ee={})).create=function(e,t){return{textDocument:e,edits:t}},te.is=function(e){let t=e;return Ut.defined(t)&&fe.is(t.textDocument)&&Array.isArray(t.edits)},(re=ne||(ne={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},re.is=function(e){let t=e;return t&&"create"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(oe=ie||(ie={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},oe.is=function(e){let t=e;return t&&"rename"===t.kind&&Ut.string(t.oldUri)&&Ut.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(se=ae||(ae={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},se.is=function(e){let t=e;return t&&"delete"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||Ut.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||Ut.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(ue||(ue={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>Ut.string(e.kind)?ne.is(e)||ie.is(e)||ae.is(e):ee.is(e))))},(de=ce||(ce={})).create=function(e){return{uri:e}},de.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)},(ge=le||(le={})).create=function(e,t){return{uri:e,version:t}},ge.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.integer(t.version)},(he=fe||(fe={})).create=function(e,t){return{uri:e,version:t}},he.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&(null===t.version||Ut.integer(t.version))},(me=pe||(pe={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},me.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.string(t.languageId)&&Ut.integer(t.version)&&Ut.string(t.text)},(be=ve||(ve={})).PlainText="plaintext",be.Markdown="markdown",be.is=function(e){const t=e;return t===be.PlainText||t===be.Markdown},(_e||(_e={})).is=function(e){const t=e;return Ut.objectLiteral(e)&&ve.is(t.kind)&&Ut.string(t.value)},(ye=ke||(ke={})).Text=1,ye.Method=2,ye.Function=3,ye.Constructor=4,ye.Field=5,ye.Variable=6,ye.Class=7,ye.Interface=8,ye.Module=9,ye.Property=10,ye.Unit=11,ye.Value=12,ye.Enum=13,ye.Keyword=14,ye.Snippet=15,ye.Color=16,ye.File=17,ye.Reference=18,ye.Folder=19,ye.EnumMember=20,ye.Constant=21,ye.Struct=22,ye.Event=23,ye.Operator=24,ye.TypeParameter=25,(xe=we||(we={})).PlainText=1,xe.Snippet=2,(Ie||(Ie={})).Deprecated=1,(Ce=Ee||(Ee={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},Ce.is=function(e){const t=e;return t&&Ut.string(t.newText)&&k.is(t.insert)&&k.is(t.replace)},(Se=Ae||(Ae={})).asIs=1,Se.adjustIndentation=2,(Re||(Re={})).is=function(e){const t=e;return t&&(Ut.string(t.detail)||void 0===t.detail)&&(Ut.string(t.description)||void 0===t.description)},(Le||(Le={})).create=function(e){return{label:e}},(Te||(Te={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(De=Me||(Me={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},De.is=function(e){const t=e;return Ut.string(t)||Ut.objectLiteral(t)&&Ut.string(t.language)&&Ut.string(t.value)},(Pe||(Pe={})).is=function(e){let t=e;return!!t&&Ut.objectLiteral(t)&&(_e.is(t.contents)||Me.is(t.contents)||Ut.typedArray(t.contents,Me.is))&&(void 0===e.range||k.is(e.range))},(Fe||(Fe={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(je||(je={})).create=function(e,t,...n){let r={label:e};return Ut.defined(t)&&(r.documentation=t),Ut.defined(n)?r.parameters=n:r.parameters=[],r},(Ue=Ne||(Ne={})).Text=1,Ue.Read=2,Ue.Write=3,(Ve||(Ve={})).create=function(e,t){let n={range:e};return Ut.number(t)&&(n.kind=t),n},(Ke=Oe||(Oe={})).File=1,Ke.Module=2,Ke.Namespace=3,Ke.Package=4,Ke.Class=5,Ke.Method=6,Ke.Property=7,Ke.Field=8,Ke.Constructor=9,Ke.Enum=10,Ke.Interface=11,Ke.Function=12,Ke.Variable=13,Ke.Constant=14,Ke.String=15,Ke.Number=16,Ke.Boolean=17,Ke.Array=18,Ke.Object=19,Ke.Key=20,Ke.Null=21,Ke.EnumMember=22,Ke.Struct=23,Ke.Event=24,Ke.Operator=25,Ke.TypeParameter=26,(We||(We={})).Deprecated=1,(He||(He={})).create=function(e,t,n,r,i){let o={name:e,kind:t,location:{uri:r,range:n}};return i&&(o.containerName=i),o},(Xe||(Xe={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},($e=ze||(ze={})).create=function(e,t,n,r,i,o){let a={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==o&&(a.children=o),a},$e.is=function(e){let t=e;return t&&Ut.string(t.name)&&Ut.number(t.kind)&&k.is(t.range)&&k.is(t.selectionRange)&&(void 0===t.detail||Ut.string(t.detail))&&(void 0===t.deprecated||Ut.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},(qe=Be||(Be={})).Empty="",qe.QuickFix="quickfix",qe.Refactor="refactor",qe.RefactorExtract="refactor.extract",qe.RefactorInline="refactor.inline",qe.RefactorRewrite="refactor.rewrite",qe.Source="source",qe.SourceOrganizeImports="source.organizeImports",qe.SourceFixAll="source.fixAll",(Ge=Qe||(Qe={})).Invoked=1,Ge.Automatic=2,(Ye=Je||(Je={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},Ye.is=function(e){let t=e;return Ut.defined(t)&&Ut.typedArray(t.diagnostics,H.is)&&(void 0===t.only||Ut.typedArray(t.only,Ut.string))&&(void 0===t.triggerKind||t.triggerKind===Qe.Invoked||t.triggerKind===Qe.Automatic)},(et=Ze||(Ze={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):z.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},et.is=function(e){let t=e;return t&&Ut.string(t.title)&&(void 0===t.diagnostics||Ut.typedArray(t.diagnostics,H.is))&&(void 0===t.kind||Ut.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||z.is(t.command))&&(void 0===t.isPreferred||Ut.boolean(t.isPreferred))&&(void 0===t.edit||ue.is(t.edit))},(nt=tt||(tt={})).create=function(e,t){let n={range:e};return Ut.defined(t)&&(n.data=t),n},nt.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.command)||z.is(t.command))},(it=rt||(rt={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},it.is=function(e){let t=e;return Ut.defined(t)&&Ut.uinteger(t.tabSize)&&Ut.boolean(t.insertSpaces)},(at=ot||(ot={})).create=function(e,t,n){return{range:e,target:t,data:n}},at.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.target)||Ut.string(t.target))},(ut=st||(st={})).create=function(e,t){return{range:e,parent:t}},ut.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(void 0===t.parent||ut.is(t.parent))},(dt=ct||(ct={})).namespace="namespace",dt.type="type",dt.class="class",dt.enum="enum",dt.interface="interface",dt.struct="struct",dt.typeParameter="typeParameter",dt.parameter="parameter",dt.variable="variable",dt.property="property",dt.enumMember="enumMember",dt.event="event",dt.function="function",dt.method="method",dt.macro="macro",dt.keyword="keyword",dt.modifier="modifier",dt.comment="comment",dt.string="string",dt.number="number",dt.regexp="regexp",dt.operator="operator",dt.decorator="decorator",(gt=lt||(lt={})).declaration="declaration",gt.definition="definition",gt.readonly="readonly",gt.static="static",gt.deprecated="deprecated",gt.abstract="abstract",gt.async="async",gt.modification="modification",gt.documentation="documentation",gt.defaultLibrary="defaultLibrary",(ft||(ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(pt=ht||(ht={})).create=function(e,t){return{range:e,text:t}},pt.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.string(t.text)},(vt=mt||(mt={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},vt.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.boolean(t.caseSensitiveLookup)&&(Ut.string(t.variableName)||void 0===t.variableName)},(_t=bt||(bt={})).create=function(e,t){return{range:e,expression:t}},_t.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&(Ut.string(t.expression)||void 0===t.expression)},(yt=kt||(kt={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},yt.is=function(e){const t=e;return Ut.defined(t)&&k.is(e.stoppedLocation)},(xt=wt||(wt={})).Type=1,xt.Parameter=2,xt.is=function(e){return 1===e||2===e},(Et=It||(It={})).create=function(e){return{value:e}},Et.is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.location||w.is(t.location))&&(void 0===t.command||z.is(t.command))},(At=Ct||(Ct={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},At.is=function(e){const t=e;return Ut.objectLiteral(t)&&b.is(t.position)&&(Ut.string(t.label)||Ut.typedArray(t.label,It.is))&&(void 0===t.kind||wt.is(t.kind))&&void 0===t.textEdits||Ut.typedArray(t.textEdits,B.is)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.paddingLeft||Ut.boolean(t.paddingLeft))&&(void 0===t.paddingRight||Ut.boolean(t.paddingRight))},(St||(St={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Rt||(Rt={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},(Lt||(Lt={})).create=function(e){return{items:e}},(Mt=Tt||(Tt={})).Invoked=0,Mt.Automatic=1,(Dt||(Dt={})).create=function(e,t){return{range:e,text:t}},(Pt||(Pt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(Ft||(Ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&f.is(t.uri)&&Ut.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),o=e.slice(r);t(i,n),t(o,n);let a=0,s=0,u=0;for(;a{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),o=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],a=e.offsetAt(n.range.start),s=e.offsetAt(n.range.end);if(!(s<=o))throw new Error("Overlapping edit");r=r.substring(0,a)+n.newText+r.substring(s,r.length),o=a}return r}}(jt||(jt={}));var Ut,Vt=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return b.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return b.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1{let t,n=e.getLanguageId();n===this._languageId&&(this._listener[e.uri.toString()]=e.onDidChangeContent((()=>{window.clearTimeout(t),t=window.setTimeout((()=>this._doValidate(e.uri,n)),500)})),this._doValidate(e.uri,n))},i=e=>{l.editor.setModelMarkers(e,this._languageId,[]);let t=e.uri.toString(),n=this._listener[t];n&&(n.dispose(),delete this._listener[t])};this._disposables.push(l.editor.onDidCreateModel(r)),this._disposables.push(l.editor.onWillDisposeModel(i)),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{i(e.model),r(e.model)}))),this._disposables.push(n((e=>{l.editor.getModels().forEach((e=>{e.getLanguageId()===this._languageId&&(i(e),r(e))}))}))),this._disposables.push({dispose:()=>{l.editor.getModels().forEach(i);for(let e in this._listener)this._listener[e].dispose()}}),l.editor.getModels().forEach(r)}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables.length=0}_doValidate(e,t){this._worker(e).then((t=>t.doValidation(e.toString()))).then((n=>{const r=n.map((e=>function(e,t){let n="number"===typeof t.code?String(t.code):t.code;return{severity:Kt(t.severity),startLineNumber:t.range.start.line+1,startColumn:t.range.start.character+1,endLineNumber:t.range.end.line+1,endColumn:t.range.end.character+1,message:t.message,code:n,source:t.source}}(0,e)));let i=l.editor.getModel(e);i&&i.getLanguageId()===t&&l.editor.setModelMarkers(i,t,r)})).then(void 0,(e=>{console.error(e)}))}};function Kt(e){switch(e){case U.Error:return l.MarkerSeverity.Error;case U.Warning:return l.MarkerSeverity.Warning;case U.Information:return l.MarkerSeverity.Info;case U.Hint:return l.MarkerSeverity.Hint;default:return l.MarkerSeverity.Info}}var Wt=class{constructor(e,t){this._worker=e,this._triggerCharacters=t}get triggerCharacters(){return this._triggerCharacters}provideCompletionItems(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doComplete(i.toString(),Ht(t)))).then((n=>{if(!n)return;const r=e.getWordUntilPosition(t),i=new l.Range(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn),o=n.items.map((e=>{const t={label:e.label,insertText:e.insertText||e.label,sortText:e.sortText,filterText:e.filterText,documentation:e.documentation,detail:e.detail,command:(n=e.command,n&&"editor.action.triggerSuggest"===n.command?{id:n.command,title:n.title,arguments:n.arguments}:void 0),range:i,kind:$t(e.kind)};var n,r;return e.textEdit&&("undefined"!==typeof(r=e.textEdit).insert&&"undefined"!==typeof r.replace?t.range={insert:zt(e.textEdit.insert),replace:zt(e.textEdit.replace)}:t.range=zt(e.textEdit.range),t.insertText=e.textEdit.newText),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),e.insertTextFormat===we.Snippet&&(t.insertTextRules=l.languages.CompletionItemInsertTextRule.InsertAsSnippet),t}));return{isIncomplete:n.isIncomplete,suggestions:o}}))}};function Ht(e){if(e)return{character:e.column-1,line:e.lineNumber-1}}function Xt(e){if(e)return{start:{line:e.startLineNumber-1,character:e.startColumn-1},end:{line:e.endLineNumber-1,character:e.endColumn-1}}}function zt(e){if(e)return new l.Range(e.start.line+1,e.start.character+1,e.end.line+1,e.end.character+1)}function $t(e){const t=l.languages.CompletionItemKind;switch(e){case ke.Text:return t.Text;case ke.Method:return t.Method;case ke.Function:return t.Function;case ke.Constructor:return t.Constructor;case ke.Field:return t.Field;case ke.Variable:return t.Variable;case ke.Class:return t.Class;case ke.Interface:return t.Interface;case ke.Module:return t.Module;case ke.Property:return t.Property;case ke.Unit:return t.Unit;case ke.Value:return t.Value;case ke.Enum:return t.Enum;case ke.Keyword:return t.Keyword;case ke.Snippet:return t.Snippet;case ke.Color:return t.Color;case ke.File:return t.File;case ke.Reference:return t.Reference}return t.Property}function Bt(e){if(e)return{range:zt(e.range),text:e.newText}}var qt=class{constructor(e){this._worker=e}provideHover(e,t,n){let r=e.uri;return this._worker(r).then((e=>e.doHover(r.toString(),Ht(t)))).then((e=>{if(e)return{range:zt(e.range),contents:Gt(e.contents)}}))}};function Qt(e){return"string"===typeof e?{value:e}:(t=e)&&"object"===typeof t&&"string"===typeof t.kind?"plaintext"===e.kind?{value:e.value.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}:{value:e.value}:{value:"```"+e.language+"\n"+e.value+"\n```\n"};var t}function Gt(e){if(e)return Array.isArray(e)?e.map(Qt):[Qt(e)]}var Jt=class{constructor(e){this._worker=e}provideDocumentHighlights(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDocumentHighlights(r.toString(),Ht(t)))).then((e=>{if(e)return e.map((e=>({range:zt(e.range),kind:Yt(e.kind)})))}))}};function Yt(e){switch(e){case Ne.Read:return l.languages.DocumentHighlightKind.Read;case Ne.Write:return l.languages.DocumentHighlightKind.Write;case Ne.Text:return l.languages.DocumentHighlightKind.Text}return l.languages.DocumentHighlightKind.Text}var Zt=class{constructor(e){this._worker=e}provideDefinition(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDefinition(r.toString(),Ht(t)))).then((e=>{if(e)return[en(e)]}))}};function en(e){return{uri:l.Uri.parse(e.uri),range:zt(e.range)}}var tn=class{constructor(e){this._worker=e}provideReferences(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.findReferences(i.toString(),Ht(t)))).then((e=>{if(e)return e.map(en)}))}},nn=class{constructor(e){this._worker=e}provideRenameEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doRename(i.toString(),Ht(t),n))).then((e=>function(e){if(!e||!e.changes)return;let t=[];for(let n in e.changes){const r=l.Uri.parse(n);for(let i of e.changes[n])t.push({resource:r,versionId:void 0,textEdit:{range:zt(i.range),text:i.newText}})}return{edits:t}}(e)))}};var rn=class{constructor(e){this._worker=e}provideDocumentSymbols(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentSymbols(n.toString()))).then((e=>{if(e)return e.map((e=>"children"in e?on(e):{name:e.name,detail:"",containerName:e.containerName,kind:an(e.kind),range:zt(e.location.range),selectionRange:zt(e.location.range),tags:[]}))}))}};function on(e){return{name:e.name,detail:e.detail??"",kind:an(e.kind),range:zt(e.range),selectionRange:zt(e.selectionRange),tags:e.tags??[],children:(e.children??[]).map((e=>on(e)))}}function an(e){let t=l.languages.SymbolKind;switch(e){case Oe.File:return t.File;case Oe.Module:return t.Module;case Oe.Namespace:return t.Namespace;case Oe.Package:return t.Package;case Oe.Class:return t.Class;case Oe.Method:return t.Method;case Oe.Property:return t.Property;case Oe.Field:return t.Field;case Oe.Constructor:return t.Constructor;case Oe.Enum:return t.Enum;case Oe.Interface:return t.Interface;case Oe.Function:return t.Function;case Oe.Variable:return t.Variable;case Oe.Constant:return t.Constant;case Oe.String:return t.String;case Oe.Number:return t.Number;case Oe.Boolean:return t.Boolean;case Oe.Array:return t.Array}return t.Function}var sn=class{constructor(e){this._worker=e}provideLinks(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentLinks(n.toString()))).then((e=>{if(e)return{links:e.map((e=>({range:zt(e.range),url:e.target})))}}))}},un=class{constructor(e){this._worker=e}provideDocumentFormattingEdits(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.format(r.toString(),null,dn(t)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}},cn=class{constructor(e){this._worker=e,this.canFormatMultipleRanges=!1}provideDocumentRangeFormattingEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.format(i.toString(),Xt(t),dn(n)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}};function dn(e){return{tabSize:e.tabSize,insertSpaces:e.insertSpaces}}var ln=class{constructor(e){this._worker=e}provideDocumentColors(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentColors(n.toString()))).then((e=>{if(e)return e.map((e=>({color:e.color,range:zt(e.range)})))}))}provideColorPresentations(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getColorPresentations(r.toString(),t.color,Xt(t.range)))).then((e=>{if(e)return e.map((e=>{let t={label:e.label};return e.textEdit&&(t.textEdit=Bt(e.textEdit)),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),t}))}))}},gn=class{constructor(e){this._worker=e}provideFoldingRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getFoldingRanges(r.toString(),t))).then((e=>{if(e)return e.map((e=>{const t={start:e.startLine+1,end:e.endLine+1};return"undefined"!==typeof e.kind&&(t.kind=function(e){switch(e){case M.Comment:return l.languages.FoldingRangeKind.Comment;case M.Imports:return l.languages.FoldingRangeKind.Imports;case M.Region:return l.languages.FoldingRangeKind.Region}return}(e.kind)),t}))}))}};var fn=class{constructor(e){this._worker=e}provideSelectionRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getSelectionRanges(r.toString(),t.map(Ht)))).then((e=>{if(e)return e.map((e=>{const t=[];for(;e;)t.push({range:zt(e.range)}),e=e.parent;return t}))}))}};function hn(e){const t=[],n=[],r=new Nt(e);t.push(r);const i=(...e)=>r.getLanguageServiceWorker(...e);return function(){const{languageId:t,modeConfiguration:r}=e;mn(n),r.completionItems&&n.push(l.languages.registerCompletionItemProvider(t,new Wt(i,["/","-",":"]))),r.hovers&&n.push(l.languages.registerHoverProvider(t,new qt(i))),r.documentHighlights&&n.push(l.languages.registerDocumentHighlightProvider(t,new Jt(i))),r.definitions&&n.push(l.languages.registerDefinitionProvider(t,new Zt(i))),r.references&&n.push(l.languages.registerReferenceProvider(t,new tn(i))),r.documentSymbols&&n.push(l.languages.registerDocumentSymbolProvider(t,new rn(i))),r.rename&&n.push(l.languages.registerRenameProvider(t,new nn(i))),r.colors&&n.push(l.languages.registerColorProvider(t,new ln(i))),r.foldingRanges&&n.push(l.languages.registerFoldingRangeProvider(t,new gn(i))),r.diagnostics&&n.push(new Ot(t,i,e.onDidChange)),r.selectionRanges&&n.push(l.languages.registerSelectionRangeProvider(t,new fn(i))),r.documentFormattingEdits&&n.push(l.languages.registerDocumentFormattingEditProvider(t,new un(i))),r.documentRangeFormattingEdits&&n.push(l.languages.registerDocumentRangeFormattingEditProvider(t,new cn(i)))}(),t.push(pn(n)),pn(t)}function pn(e){return{dispose:()=>mn(e)}}function mn(e){for(;e.length;)e.pop().dispose()}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2251.651c81f8.chunk.js b/ydb/core/viewer/monitoring/static/js/2251.651c81f8.chunk.js new file mode 100644 index 000000000000..6eb0792941b0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/2251.651c81f8.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2251],{2251:(E,T,L)=>{L.d(T,{default:()=>A});var N=L(39792);const A=L.n(N)()},39792:E=>{function T(E){E.languages.fortran={"quoted-number":{pattern:/[BOZ](['"])[A-F0-9]+\1/i,alias:"number"},string:{pattern:/(?:\b\w+_)?(['"])(?:\1\1|&(?:\r\n?|\n)(?:[ \t]*!.*(?:\r\n?|\n)|(?![ \t]*!))|(?!\1).)*(?:\1|&)/,inside:{comment:{pattern:/(&(?:\r\n?|\n)\s*)!.*/,lookbehind:!0}}},comment:{pattern:/!.*/,greedy:!0},boolean:/\.(?:FALSE|TRUE)\.(?:_\w+)?/i,number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[ED][+-]?\d+)?(?:_\w+)?/i,keyword:[/\b(?:CHARACTER|COMPLEX|DOUBLE ?PRECISION|INTEGER|LOGICAL|REAL)\b/i,/\b(?:END ?)?(?:BLOCK ?DATA|DO|FILE|FORALL|FUNCTION|IF|INTERFACE|MODULE(?! PROCEDURE)|PROGRAM|SELECT|SUBROUTINE|TYPE|WHERE)\b/i,/\b(?:ALLOCATABLE|ALLOCATE|BACKSPACE|CALL|CASE|CLOSE|COMMON|CONTAINS|CONTINUE|CYCLE|DATA|DEALLOCATE|DIMENSION|DO|END|EQUIVALENCE|EXIT|EXTERNAL|FORMAT|GO ?TO|IMPLICIT(?: NONE)?|INQUIRE|INTENT|INTRINSIC|MODULE PROCEDURE|NAMELIST|NULLIFY|OPEN|OPTIONAL|PARAMETER|POINTER|PRINT|PRIVATE|PUBLIC|READ|RETURN|REWIND|SAVE|SELECT|STOP|TARGET|WHILE|WRITE)\b/i,/\b(?:ASSIGNMENT|DEFAULT|ELEMENTAL|ELSE|ELSEIF|ELSEWHERE|ENTRY|IN|INCLUDE|INOUT|KIND|NULL|ONLY|OPERATOR|OUT|PURE|RECURSIVE|RESULT|SEQUENCE|STAT|THEN|USE)\b/i],operator:[/\*\*|\/\/|=>|[=\/]=|[<>]=?|::|[+\-*=%]|\.[A-Z]+\./i,{pattern:/(^|(?!\().)\/(?!\))/,lookbehind:!0}],punctuation:/\(\/|\/\)|[(),;:&]/}}E.exports=T,T.displayName="fortran",T.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/22609.bdebad49.chunk.js b/ydb/core/viewer/monitoring/static/js/22609.bdebad49.chunk.js new file mode 100644 index 000000000000..bd8b78975dca --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/22609.bdebad49.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[22609],{22609:(e,a,n)=>{n.d(a,{default:()=>s});var t=n(49784);const s=n.n(t)()},49784:(e,a,n)=>{var t=n(51572);function s(e){e.register(t),function(e){e.languages.handlebars={comment:/\{\{![\s\S]*?\}\}/,delimiter:{pattern:/^\{\{\{?|\}\}\}?$/,alias:"punctuation"},string:/(["'])(?:\\.|(?!\1)[^\\\r\n])*\1/,number:/\b0x[\dA-Fa-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee][+-]?\d+)?/,boolean:/\b(?:false|true)\b/,block:{pattern:/^(\s*(?:~\s*)?)[#\/]\S+?(?=\s*(?:~\s*)?$|\s)/,lookbehind:!0,alias:"keyword"},brackets:{pattern:/\[[^\]]+\]/,inside:{punctuation:/\[|\]/,variable:/[\s\S]+/}},punctuation:/[!"#%&':()*+,.\/;<=>@\[\\\]^`{|}~]/,variable:/[^!"#%&'()*+,\/;<=>@\[\\\]^`{|}~\s]+/},e.hooks.add("before-tokenize",(function(a){e.languages["markup-templating"].buildPlaceholders(a,"handlebars",/\{\{\{[\s\S]+?\}\}\}|\{\{[\s\S]+?\}\}/g)})),e.hooks.add("after-tokenize",(function(a){e.languages["markup-templating"].tokenizePlaceholders(a,"handlebars")})),e.languages.hbs=e.languages.handlebars}(e)}e.exports=s,s.displayName="handlebars",s.aliases=["hbs"]},51572:e=>{function a(e){!function(e){function a(e,a){return"___"+e.toUpperCase()+a+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(n,t,s,r){if(n.language===t){var o=n.tokenStack=[];n.code=n.code.replace(s,(function(e){if("function"===typeof r&&!r(e))return e;for(var s,i=o.length;-1!==n.code.indexOf(s=a(t,i));)++i;return o[i]=e,s})),n.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(n,t){if(n.language===t&&n.tokenStack){n.grammar=e.languages[t];var s=0,r=Object.keys(n.tokenStack);!function o(i){for(var l=0;l=r.length);l++){var u=i[l];if("string"===typeof u||u.content&&"string"===typeof u.content){var c=r[s],g=n.tokenStack[c],d="string"===typeof u?u:u.content,p=a(t,c),b=d.indexOf(p);if(b>-1){++s;var f=d.substring(0,b),k=new e.Token(t,e.tokenize(g,n.grammar),"language-"+t,g),h=d.substring(b+p.length),m=[];f&&m.push.apply(m,o([f])),m.push(k),h&&m.push.apply(m,o([h])),"string"===typeof u?i.splice.apply(i,[l,1].concat(m)):u.content=m}}else u.content&&o(u.content)}return i}(n.tokens)}}}})}(e)}e.exports=a,a.displayName="markupTemplating",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/22626.2495b693.chunk.js b/ydb/core/viewer/monitoring/static/js/22626.2495b693.chunk.js new file mode 100644 index 000000000000..f4e9c0c2be28 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/22626.2495b693.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[22626],{22626:function(e,_,t){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=_(e),a={name:"bs",weekdays:"nedjelja_ponedjeljak_utorak_srijeda_\u010detvrtak_petak_subota".split("_"),months:"januar_februar_mart_april_maj_juni_juli_august_septembar_oktobar_novembar_decembar".split("_"),weekStart:1,weekdaysShort:"ned._pon._uto._sri._\u010det._pet._sub.".split("_"),monthsShort:"jan._feb._mar._apr._maj._jun._jul._aug._sep._okt._nov._dec.".split("_"),weekdaysMin:"ne_po_ut_sr_\u010de_pe_su".split("_"),ordinal:function(e){return e},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm"}};return t.default.locale(a,null,!0),a}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2286.e992ffd4.chunk.js b/ydb/core/viewer/monitoring/static/js/2286.e992ffd4.chunk.js deleted file mode 100644 index a80663c048c7..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2286.e992ffd4.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2286],{32286:function(a,u,e){a.exports=function(a){"use strict";function u(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var e=u(a),i={name:"rw",weekdays:"Ku Cyumweru_Kuwa Mbere_Kuwa Kabiri_Kuwa Gatatu_Kuwa Kane_Kuwa Gatanu_Kuwa Gatandatu".split("_"),months:"Mutarama_Gashyantare_Werurwe_Mata_Gicurasi_Kamena_Nyakanga_Kanama_Nzeri_Ukwakira_Ugushyingo_Ukuboza".split("_"),relativeTime:{future:"mu %s",past:"%s",s:"amasegonda",m:"Umunota",mm:"%d iminota",h:"isaha",hh:"%d amasaha",d:"Umunsi",dd:"%d iminsi",M:"ukwezi",MM:"%d amezi",y:"umwaka",yy:"%d imyaka"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},ordinal:function(a){return a}};return e.default.locale(i,null,!0),i}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/23039.f34c5f78.chunk.js b/ydb/core/viewer/monitoring/static/js/23039.f34c5f78.chunk.js new file mode 100644 index 000000000000..d9dd726edd09 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/23039.f34c5f78.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[23039],{11632:e=>{function s(e){!function(e){function s(e){return RegExp(/([ \t])/.source+"(?:"+e+")"+/(?=[\s;]|$)/.source,"i")}e.languages.csp={directive:{pattern:/(^|[\s;])(?:base-uri|block-all-mixed-content|(?:child|connect|default|font|frame|img|manifest|media|object|prefetch|script|style|worker)-src|disown-opener|form-action|frame-(?:ancestors|options)|input-protection(?:-(?:clip|selectors))?|navigate-to|plugin-types|policy-uri|referrer|reflected-xss|report-(?:to|uri)|require-sri-for|sandbox|(?:script|style)-src-(?:attr|elem)|upgrade-insecure-requests)(?=[\s;]|$)/i,lookbehind:!0,alias:"property"},scheme:{pattern:s(/[a-z][a-z0-9.+-]*:/.source),lookbehind:!0},none:{pattern:s(/'none'/.source),lookbehind:!0,alias:"keyword"},nonce:{pattern:s(/'nonce-[-+/\w=]+'/.source),lookbehind:!0,alias:"number"},hash:{pattern:s(/'sha(?:256|384|512)-[-+/\w=]+'/.source),lookbehind:!0,alias:"number"},host:{pattern:s(/[a-z][a-z0-9.+-]*:\/\/[^\s;,']*/.source+"|"+/\*[^\s;,']*/.source+"|"+/[a-z0-9-]+(?:\.[a-z0-9-]+)+(?::[\d*]+)?(?:\/[^\s;,']*)?/.source),lookbehind:!0,alias:"url",inside:{important:/\*/}},keyword:[{pattern:s(/'unsafe-[a-z-]+'/.source),lookbehind:!0,alias:"unsafe"},{pattern:s(/'[a-z-]+'/.source),lookbehind:!0,alias:"safe"}],punctuation:/;/}}(e)}e.exports=s,s.displayName="csp",s.aliases=[]},23039:(e,s,o)=>{o.d(s,{default:()=>a});var r=o(11632);const a=o.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2308.9e3a980c.chunk.js b/ydb/core/viewer/monitoring/static/js/2308.9e3a980c.chunk.js deleted file mode 100644 index be09fe23fc27..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2308.9e3a980c.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2308],{62308:(e,t,n)=>{n.r(t),n.d(t,{getCLS:()=>p,getFCP:()=>y,getFID:()=>k,getLCP:()=>F,getTTFB:()=>C});var i,a,r,o,u=function(e,t){return{name:e,value:void 0===t?-1:t,delta:0,entries:[],id:"v1-".concat(Date.now(),"-").concat(Math.floor(8999999999999*Math.random())+1e12)}},c=function(e,t){try{if(PerformanceObserver.supportedEntryTypes.includes(e)){if("first-input"===e&&!("PerformanceEventTiming"in self))return;var n=new PerformanceObserver((function(e){return e.getEntries().map(t)}));return n.observe({type:e,buffered:!0}),n}}catch(e){}},s=function(e,t){var n=function n(i){"pagehide"!==i.type&&"hidden"!==document.visibilityState||(e(i),t&&(removeEventListener("visibilitychange",n,!0),removeEventListener("pagehide",n,!0)))};addEventListener("visibilitychange",n,!0),addEventListener("pagehide",n,!0)},f=function(e){addEventListener("pageshow",(function(t){t.persisted&&e(t)}),!0)},d="function"==typeof WeakSet?new WeakSet:new Set,m=function(e,t,n){var i;return function(){t.value>=0&&(n||d.has(t)||"hidden"===document.visibilityState)&&(t.delta=t.value-(i||0),(t.delta||void 0===i)&&(i=t.value,e(t)))}},p=function(e,t){var n,i=u("CLS",0),a=function(e){e.hadRecentInput||(i.value+=e.value,i.entries.push(e),n())},r=c("layout-shift",a);r&&(n=m(e,i,t),s((function(){r.takeRecords().map(a),n()})),f((function(){i=u("CLS",0),n=m(e,i,t)})))},v=-1,l=function(){return"hidden"===document.visibilityState?0:1/0},h=function(){s((function(e){var t=e.timeStamp;v=t}),!0)},g=function(){return v<0&&(v=l(),h(),f((function(){setTimeout((function(){v=l(),h()}),0)}))),{get timeStamp(){return v}}},y=function(e,t){var n,i=g(),a=u("FCP"),r=function(e){"first-contentful-paint"===e.name&&(s&&s.disconnect(),e.startTime=0&&a1e12?new Date:performance.now())-e.timeStamp;"pointerdown"==e.type?function(e,t){var n=function(){b(e,t),a()},i=function(){a()},a=function(){removeEventListener("pointerup",n,S),removeEventListener("pointercancel",i,S)};addEventListener("pointerup",n,S),addEventListener("pointercancel",i,S)}(t,e):b(t,e)}},L=function(e){["mousedown","keydown","touchstart","pointerdown"].forEach((function(t){return e(t,w,S)}))},k=function(e,t){var n,r=g(),p=u("FID"),v=function(e){e.startTime{s.r(t),s.d(t,{conf:()=>r,language:()=>i});var r={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},i={defaultToken:"",tokenPostfix:".perl",brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:["__DATA__","else","lock","__END__","elsif","lt","__FILE__","eq","__LINE__","exp","ne","sub","__PACKAGE__","for","no","and","foreach","or","unless","cmp","ge","package","until","continue","gt","while","CORE","if","xor","do","le","__DIE__","__WARN__"],builtinFunctions:["-A","END","length","setpgrp","-B","endgrent","link","setpriority","-b","endhostent","listen","setprotoent","-C","endnetent","local","setpwent","-c","endprotoent","localtime","setservent","-d","endpwent","log","setsockopt","-e","endservent","lstat","shift","-f","eof","map","shmctl","-g","eval","mkdir","shmget","-k","exec","msgctl","shmread","-l","exists","msgget","shmwrite","-M","exit","msgrcv","shutdown","-O","fcntl","msgsnd","sin","-o","fileno","my","sleep","-p","flock","next","socket","-r","fork","not","socketpair","-R","format","oct","sort","-S","formline","open","splice","-s","getc","opendir","split","-T","getgrent","ord","sprintf","-t","getgrgid","our","sqrt","-u","getgrnam","pack","srand","-w","gethostbyaddr","pipe","stat","-W","gethostbyname","pop","state","-X","gethostent","pos","study","-x","getlogin","print","substr","-z","getnetbyaddr","printf","symlink","abs","getnetbyname","prototype","syscall","accept","getnetent","push","sysopen","alarm","getpeername","quotemeta","sysread","atan2","getpgrp","rand","sysseek","AUTOLOAD","getppid","read","system","BEGIN","getpriority","readdir","syswrite","bind","getprotobyname","readline","tell","binmode","getprotobynumber","readlink","telldir","bless","getprotoent","readpipe","tie","break","getpwent","recv","tied","caller","getpwnam","redo","time","chdir","getpwuid","ref","times","CHECK","getservbyname","rename","truncate","chmod","getservbyport","require","uc","chomp","getservent","reset","ucfirst","chop","getsockname","return","umask","chown","getsockopt","reverse","undef","chr","glob","rewinddir","UNITCHECK","chroot","gmtime","rindex","unlink","close","goto","rmdir","unpack","closedir","grep","say","unshift","connect","hex","scalar","untie","cos","index","seek","use","crypt","INIT","seekdir","utime","dbmclose","int","select","values","dbmopen","ioctl","semctl","vec","defined","join","semget","wait","delete","keys","semop","waitpid","DESTROY","kill","send","wantarray","die","last","setgrent","warn","dump","lc","sethostent","write","each","lcfirst","setnetent"],builtinFileHandlers:["ARGV","STDERR","STDOUT","ARGVOUT","STDIN","ENV"],builtinVariables:["$!","$^RE_TRIE_MAXBUF","$LAST_REGEXP_CODE_RESULT",'$"',"$^S","$LIST_SEPARATOR","$#","$^T","$MATCH","$$","$^TAINT","$MULTILINE_MATCHING","$%","$^UNICODE","$NR","$&","$^UTF8LOCALE","$OFMT","$'","$^V","$OFS","$(","$^W","$ORS","$)","$^WARNING_BITS","$OS_ERROR","$*","$^WIDE_SYSTEM_CALLS","$OSNAME","$+","$^X","$OUTPUT_AUTO_FLUSH","$,","$_","$OUTPUT_FIELD_SEPARATOR","$-","$`","$OUTPUT_RECORD_SEPARATOR","$.","$a","$PERL_VERSION","$/","$ACCUMULATOR","$PERLDB","$0","$ARG","$PID","$:","$ARGV","$POSTMATCH","$;","$b","$PREMATCH","$<","$BASETIME","$PROCESS_ID","$=","$CHILD_ERROR","$PROGRAM_NAME","$>","$COMPILING","$REAL_GROUP_ID","$?","$DEBUGGING","$REAL_USER_ID","$@","$EFFECTIVE_GROUP_ID","$RS","$[","$EFFECTIVE_USER_ID","$SUBSCRIPT_SEPARATOR","$\\","$EGID","$SUBSEP","$]","$ERRNO","$SYSTEM_FD_MAX","$^","$EUID","$UID","$^A","$EVAL_ERROR","$WARNING","$^C","$EXCEPTIONS_BEING_CAUGHT","$|","$^CHILD_ERROR_NATIVE","$EXECUTABLE_NAME","$~","$^D","$EXTENDED_OS_ERROR","%!","$^E","$FORMAT_FORMFEED","%^H","$^ENCODING","$FORMAT_LINE_BREAK_CHARACTERS","%ENV","$^F","$FORMAT_LINES_LEFT","%INC","$^H","$FORMAT_LINES_PER_PAGE","%OVERLOAD","$^I","$FORMAT_NAME","%SIG","$^L","$FORMAT_PAGE_NUMBER","@+","$^M","$FORMAT_TOP_NAME","@-","$^N","$GID","@_","$^O","$INPLACE_EDIT","@ARGV","$^OPEN","$INPUT_LINE_NUMBER","@INC","$^P","$INPUT_RECORD_SEPARATOR","@LAST_MATCH_START","$^R","$LAST_MATCH_END","$^RE_DEBUG_FLAGS","$LAST_PAREN_MATCH"],symbols:/[:+\-\^*$&%@=<>!?|\/~\.]/,quoteLikeOps:["qr","m","s","q","qq","qx","qw","tr","y"],escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[{include:"@whitespace"},[/[a-zA-Z\-_][\w\-_]*/,{cases:{"@keywords":"keyword","@builtinFunctions":"type.identifier","@builtinFileHandlers":"variable.predefined","@quoteLikeOps":{token:"@rematch",next:"quotedConstructs"},"@default":""}}],[/[\$@%][*@#?\+\-\$!\w\\\^><~:;\.]+/,{cases:{"@builtinVariables":"variable.predefined","@default":"variable"}}],{include:"@strings"},{include:"@dblStrings"},{include:"@perldoc"},{include:"@heredoc"},[/[{}\[\]()]/,"@brackets"],[/[\/](?:(?:\[(?:\\]|[^\]])+\])|(?:\\\/|[^\]\/]))*[\/]\w*\s*(?=[).,;]|$)/,"regexp"],[/@symbols/,"operators"],{include:"@numbers"},[/[,;]/,"delimiter"]],whitespace:[[/\s+/,"white"],[/(^#!.*$)/,"metatag"],[/(^#.*$)/,"comment"]],numbers:[[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F_]*[0-9a-fA-F]/,"number.hex"],[/\d+/,"number"]],strings:[[/'/,"string","@stringBody"]],stringBody:[[/'/,"string","@popall"],[/\\'/,"string.escape"],[/./,"string"]],dblStrings:[[/"/,"string","@dblStringBody"]],dblStringBody:[[/"/,"string","@popall"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],{include:"@variables"},[/./,"string"]],quotedConstructs:[[/(q|qw|tr|y)\s*\(/,{token:"string.delim",switchTo:"@qstring.(.)"}],[/(q|qw|tr|y)\s*\[/,{token:"string.delim",switchTo:"@qstring.[.]"}],[/(q|qw|tr|y)\s*\{/,{token:"string.delim",switchTo:"@qstring.{.}"}],[/(q|qw|tr|y)\s*"}],[/(q|qw|tr|y)#/,{token:"string.delim",switchTo:"@qstring.#.#"}],[/(q|qw|tr|y)\s*([^A-Za-z0-9#\s])/,{token:"string.delim",switchTo:"@qstring.$2.$2"}],[/(q|qw|tr|y)\s+(\w)/,{token:"string.delim",switchTo:"@qstring.$2.$2"}],[/(qr|m|s)\s*\(/,{token:"regexp.delim",switchTo:"@qregexp.(.)"}],[/(qr|m|s)\s*\[/,{token:"regexp.delim",switchTo:"@qregexp.[.]"}],[/(qr|m|s)\s*\{/,{token:"regexp.delim",switchTo:"@qregexp.{.}"}],[/(qr|m|s)\s*"}],[/(qr|m|s)#/,{token:"regexp.delim",switchTo:"@qregexp.#.#"}],[/(qr|m|s)\s*([^A-Za-z0-9_#\s])/,{token:"regexp.delim",switchTo:"@qregexp.$2.$2"}],[/(qr|m|s)\s+(\w)/,{token:"regexp.delim",switchTo:"@qregexp.$2.$2"}],[/(qq|qx)\s*\(/,{token:"string.delim",switchTo:"@qqstring.(.)"}],[/(qq|qx)\s*\[/,{token:"string.delim",switchTo:"@qqstring.[.]"}],[/(qq|qx)\s*\{/,{token:"string.delim",switchTo:"@qqstring.{.}"}],[/(qq|qx)\s*"}],[/(qq|qx)#/,{token:"string.delim",switchTo:"@qqstring.#.#"}],[/(qq|qx)\s*([^A-Za-z0-9#\s])/,{token:"string.delim",switchTo:"@qqstring.$2.$2"}],[/(qq|qx)\s+(\w)/,{token:"string.delim",switchTo:"@qqstring.$2.$2"}]],qstring:[[/\\./,"string.escape"],[/./,{cases:{"$#==$S3":{token:"string.delim",next:"@pop"},"$#==$S2":{token:"string.delim",next:"@push"},"@default":"string"}}]],qregexp:[{include:"@variables"},[/\\./,"regexp.escape"],[/./,{cases:{"$#==$S3":{token:"regexp.delim",next:"@regexpModifiers"},"$#==$S2":{token:"regexp.delim",next:"@push"},"@default":"regexp"}}]],regexpModifiers:[[/[msixpodualngcer]+/,{token:"regexp.modifier",next:"@popall"}]],qqstring:[{include:"@variables"},{include:"@qstring"}],heredoc:[[/<<\s*['"`]?([\w\-]+)['"`]?/,{token:"string.heredoc.delimiter",next:"@heredocBody.$1"}]],heredocBody:[[/^([\w\-]+)$/,{cases:{"$1==$S2":[{token:"string.heredoc.delimiter",next:"@popall"}],"@default":"string.heredoc"}}],[/./,"string.heredoc"]],perldoc:[[/^=\w/,"comment.doc","@perldocBody"]],perldocBody:[[/^=cut\b/,"type.identifier","@popall"],[/./,"comment.doc"]],variables:[[/\$\w+/,"variable"],[/@\w+/,"variable"],[/%\w+/,"variable"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/225.cf362439.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/23158.a522a83d.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/225.cf362439.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/23158.a522a83d.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/23321.4a32d0c2.chunk.js b/ydb/core/viewer/monitoring/static/js/23321.4a32d0c2.chunk.js new file mode 100644 index 000000000000..921ec418a8a9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/23321.4a32d0c2.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[23321],{23321:function(e,d,_){e.exports=function(e){"use strict";function d(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=d(e),s={name:"oc-lnc",weekdays:"dimenge_diluns_dimars_dim\xe8cres_dij\xf2us_divendres_dissabte".split("_"),weekdaysShort:"Dg_Dl_Dm_Dc_Dj_Dv_Ds".split("_"),weekdaysMin:"dg_dl_dm_dc_dj_dv_ds".split("_"),months:"geni\xe8r_febri\xe8r_mar\xe7_abrial_mai_junh_julhet_agost_setembre_oct\xf2bre_novembre_decembre".split("_"),monthsShort:"gen_feb_mar\xe7_abr_mai_junh_julh_ago_set_oct_nov_dec".split("_"),weekStart:1,formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM [de] YYYY",LLL:"D MMMM [de] YYYY [a] H:mm",LLLL:"dddd D MMMM [de] YYYY [a] H:mm"},relativeTime:{future:"d'aqu\xed %s",past:"fa %s",s:"unas segondas",m:"una minuta",mm:"%d minutas",h:"una ora",hh:"%d oras",d:"un jorn",dd:"%d jorns",M:"un mes",MM:"%d meses",y:"un an",yy:"%d ans"},ordinal:function(e){return e+"\xba"}};return _.default.locale(s,null,!0),s}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2350.a7af0a2e.chunk.js b/ydb/core/viewer/monitoring/static/js/2350.a7af0a2e.chunk.js deleted file mode 100644 index 936b96f80a1c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2350.a7af0a2e.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2350.a7af0a2e.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2350],{62350:(e,i,t)=>{t.r(i),t.d(i,{conf:()=>n,language:()=>s});var n={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"<",close:">"}],folding:{markers:{start:new RegExp("^\\s*//\\s*(?:(?:#?region\\b)|(?:))")}}},s={defaultToken:"",tokenPostfix:".kt",keywords:["as","as?","break","class","continue","do","else","false","for","fun","if","in","!in","interface","is","!is","null","object","package","return","super","this","throw","true","try","typealias","val","var","when","while","by","catch","constructor","delegate","dynamic","field","file","finally","get","import","init","param","property","receiver","set","setparam","where","actual","abstract","annotation","companion","const","crossinline","data","enum","expect","external","final","infix","inline","inner","internal","lateinit","noinline","open","operator","out","override","private","protected","public","reified","sealed","suspend","tailrec","vararg","field","it"],operators:["+","-","*","/","%","=","+=","-=","*=","/=","%=","++","--","&&","||","!","==","!=","===","!==",">","<","<=",">=","[","]","!!","?.","?:","::","..",":","?","->","@",";","$","_"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/@\s*[a-zA-Z_\$][\w\$]*/,"annotation"],[/(@digits)[eE]([\-+]?(@digits))?[fFdD]?/,"number.float"],[/(@digits)\.(@digits)([eE][\-+]?(@digits))?[fFdD]?/,"number.float"],[/0[xX](@hexdigits)[Ll]?/,"number.hex"],[/0(@octaldigits)[Ll]?/,"number.octal"],[/0[bB](@binarydigits)[Ll]?/,"number.binary"],[/(@digits)[fFdD]/,"number.float"],[/(@digits)[lL]?/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"""/,"string","@multistring"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@javadoc"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],javadoc:[[/[^\/*]+/,"comment.doc"],[/\/\*/,"comment.doc","@push"],[/\/\*/,"comment.doc.invalid"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],multistring:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"""/,"string","@pop"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/23702.887336e8.chunk.js b/ydb/core/viewer/monitoring/static/js/23702.887336e8.chunk.js new file mode 100644 index 000000000000..b55444f595cc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/23702.887336e8.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 23702.887336e8.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[23702],{23702:(e,_,t)=>{t.r(_),t.d(_,{conf:()=>r,language:()=>i});var r={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},i={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["AES128","AES256","ALL","ALLOWOVERWRITE","ANALYSE","ANALYZE","AND","ANY","ARRAY","AS","ASC","AUTHORIZATION","AZ64","BACKUP","BETWEEN","BINARY","BLANKSASNULL","BOTH","BYTEDICT","BZIP2","CASE","CAST","CHECK","COLLATE","COLUMN","CONSTRAINT","CREATE","CREDENTIALS","CROSS","CURRENT_DATE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURRENT_USER_ID","DEFAULT","DEFERRABLE","DEFLATE","DEFRAG","DELTA","DELTA32K","DESC","DISABLE","DISTINCT","DO","ELSE","EMPTYASNULL","ENABLE","ENCODE","ENCRYPT","ENCRYPTION","END","EXCEPT","EXPLICIT","FALSE","FOR","FOREIGN","FREEZE","FROM","FULL","GLOBALDICT256","GLOBALDICT64K","GRANT","GROUP","GZIP","HAVING","IDENTITY","IGNORE","ILIKE","IN","INITIALLY","INNER","INTERSECT","INTO","IS","ISNULL","JOIN","LANGUAGE","LEADING","LEFT","LIKE","LIMIT","LOCALTIME","LOCALTIMESTAMP","LUN","LUNS","LZO","LZOP","MINUS","MOSTLY16","MOSTLY32","MOSTLY8","NATURAL","NEW","NOT","NOTNULL","NULL","NULLS","OFF","OFFLINE","OFFSET","OID","OLD","ON","ONLY","OPEN","OR","ORDER","OUTER","OVERLAPS","PARALLEL","PARTITION","PERCENT","PERMISSIONS","PLACING","PRIMARY","RAW","READRATIO","RECOVER","REFERENCES","RESPECT","REJECTLOG","RESORT","RESTORE","RIGHT","SELECT","SESSION_USER","SIMILAR","SNAPSHOT","SOME","SYSDATE","SYSTEM","TABLE","TAG","TDES","TEXT255","TEXT32K","THEN","TIMESTAMP","TO","TOP","TRAILING","TRUE","TRUNCATECOLUMNS","UNION","UNIQUE","USER","USING","VERBOSE","WALLET","WHEN","WHERE","WITH","WITHOUT"],operators:["AND","BETWEEN","IN","LIKE","NOT","OR","IS","NULL","INTERSECT","UNION","INNER","JOIN","LEFT","OUTER","RIGHT"],builtinFunctions:["current_schema","current_schemas","has_database_privilege","has_schema_privilege","has_table_privilege","age","current_time","current_timestamp","localtime","isfinite","now","ascii","get_bit","get_byte","set_bit","set_byte","to_ascii","approximate percentile_disc","avg","count","listagg","max","median","min","percentile_cont","stddev_samp","stddev_pop","sum","var_samp","var_pop","bit_and","bit_or","bool_and","bool_or","cume_dist","first_value","lag","last_value","lead","nth_value","ratio_to_report","dense_rank","ntile","percent_rank","rank","row_number","case","coalesce","decode","greatest","least","nvl","nvl2","nullif","add_months","at time zone","convert_timezone","current_date","date_cmp","date_cmp_timestamp","date_cmp_timestamptz","date_part_year","dateadd","datediff","date_part","date_trunc","extract","getdate","interval_cmp","last_day","months_between","next_day","sysdate","timeofday","timestamp_cmp","timestamp_cmp_date","timestamp_cmp_timestamptz","timestamptz_cmp","timestamptz_cmp_date","timestamptz_cmp_timestamp","timezone","to_timestamp","trunc","abs","acos","asin","atan","atan2","cbrt","ceil","ceiling","checksum","cos","cot","degrees","dexp","dlog1","dlog10","exp","floor","ln","log","mod","pi","power","radians","random","round","sin","sign","sqrt","tan","to_hex","bpcharcmp","btrim","bttext_pattern_cmp","char_length","character_length","charindex","chr","concat","crc32","func_sha1","initcap","left and rights","len","length","lower","lpad and rpads","ltrim","md5","octet_length","position","quote_ident","quote_literal","regexp_count","regexp_instr","regexp_replace","regexp_substr","repeat","replace","replicate","reverse","rtrim","split_part","strpos","strtol","substring","textlen","translate","trim","upper","cast","convert","to_char","to_date","to_number","json_array_length","json_extract_array_element_text","json_extract_path_text","current_setting","pg_cancel_backend","pg_terminate_backend","set_config","current_database","current_user","current_user_id","pg_backend_pid","pg_last_copy_count","pg_last_copy_id","pg_last_query_id","pg_last_unload_count","session_user","slice_num","user","version","abbrev","acosd","any","area","array_agg","array_append","array_cat","array_dims","array_fill","array_length","array_lower","array_ndims","array_position","array_positions","array_prepend","array_remove","array_replace","array_to_json","array_to_string","array_to_tsvector","array_upper","asind","atan2d","atand","bit","bit_length","bound_box","box","brin_summarize_new_values","broadcast","cardinality","center","circle","clock_timestamp","col_description","concat_ws","convert_from","convert_to","corr","cosd","cotd","covar_pop","covar_samp","current_catalog","current_query","current_role","currval","cursor_to_xml","diameter","div","encode","enum_first","enum_last","enum_range","every","family","format","format_type","generate_series","generate_subscripts","get_current_ts_config","gin_clean_pending_list","grouping","has_any_column_privilege","has_column_privilege","has_foreign_data_wrapper_privilege","has_function_privilege","has_language_privilege","has_sequence_privilege","has_server_privilege","has_tablespace_privilege","has_type_privilege","height","host","hostmask","inet_client_addr","inet_client_port","inet_merge","inet_same_family","inet_server_addr","inet_server_port","isclosed","isempty","isopen","json_agg","json_object","json_object_agg","json_populate_record","json_populate_recordset","json_to_record","json_to_recordset","jsonb_agg","jsonb_object_agg","justify_days","justify_hours","justify_interval","lastval","left","line","localtimestamp","lower_inc","lower_inf","lpad","lseg","make_date","make_interval","make_time","make_timestamp","make_timestamptz","masklen","mode","netmask","network","nextval","npoints","num_nonnulls","num_nulls","numnode","obj_description","overlay","parse_ident","path","pclose","percentile_disc","pg_advisory_lock","pg_advisory_lock_shared","pg_advisory_unlock","pg_advisory_unlock_all","pg_advisory_unlock_shared","pg_advisory_xact_lock","pg_advisory_xact_lock_shared","pg_backup_start_time","pg_blocking_pids","pg_client_encoding","pg_collation_is_visible","pg_column_size","pg_conf_load_time","pg_control_checkpoint","pg_control_init","pg_control_recovery","pg_control_system","pg_conversion_is_visible","pg_create_logical_replication_slot","pg_create_physical_replication_slot","pg_create_restore_point","pg_current_xlog_flush_location","pg_current_xlog_insert_location","pg_current_xlog_location","pg_database_size","pg_describe_object","pg_drop_replication_slot","pg_export_snapshot","pg_filenode_relation","pg_function_is_visible","pg_get_constraintdef","pg_get_expr","pg_get_function_arguments","pg_get_function_identity_arguments","pg_get_function_result","pg_get_functiondef","pg_get_indexdef","pg_get_keywords","pg_get_object_address","pg_get_owned_sequence","pg_get_ruledef","pg_get_serial_sequence","pg_get_triggerdef","pg_get_userbyid","pg_get_viewdef","pg_has_role","pg_identify_object","pg_identify_object_as_address","pg_index_column_has_property","pg_index_has_property","pg_indexam_has_property","pg_indexes_size","pg_is_in_backup","pg_is_in_recovery","pg_is_other_temp_schema","pg_is_xlog_replay_paused","pg_last_committed_xact","pg_last_xact_replay_timestamp","pg_last_xlog_receive_location","pg_last_xlog_replay_location","pg_listening_channels","pg_logical_emit_message","pg_logical_slot_get_binary_changes","pg_logical_slot_get_changes","pg_logical_slot_peek_binary_changes","pg_logical_slot_peek_changes","pg_ls_dir","pg_my_temp_schema","pg_notification_queue_usage","pg_opclass_is_visible","pg_operator_is_visible","pg_opfamily_is_visible","pg_options_to_table","pg_postmaster_start_time","pg_read_binary_file","pg_read_file","pg_relation_filenode","pg_relation_filepath","pg_relation_size","pg_reload_conf","pg_replication_origin_create","pg_replication_origin_drop","pg_replication_origin_oid","pg_replication_origin_progress","pg_replication_origin_session_is_setup","pg_replication_origin_session_progress","pg_replication_origin_session_reset","pg_replication_origin_session_setup","pg_replication_origin_xact_reset","pg_replication_origin_xact_setup","pg_rotate_logfile","pg_size_bytes","pg_size_pretty","pg_sleep","pg_sleep_for","pg_sleep_until","pg_start_backup","pg_stat_file","pg_stop_backup","pg_switch_xlog","pg_table_is_visible","pg_table_size","pg_tablespace_databases","pg_tablespace_location","pg_tablespace_size","pg_total_relation_size","pg_trigger_depth","pg_try_advisory_lock","pg_try_advisory_lock_shared","pg_try_advisory_xact_lock","pg_try_advisory_xact_lock_shared","pg_ts_config_is_visible","pg_ts_dict_is_visible","pg_ts_parser_is_visible","pg_ts_template_is_visible","pg_type_is_visible","pg_typeof","pg_xact_commit_timestamp","pg_xlog_location_diff","pg_xlog_replay_pause","pg_xlog_replay_resume","pg_xlogfile_name","pg_xlogfile_name_offset","phraseto_tsquery","plainto_tsquery","point","polygon","popen","pqserverversion","query_to_xml","querytree","quote_nullable","radius","range_merge","regexp_matches","regexp_split_to_array","regexp_split_to_table","regr_avgx","regr_avgy","regr_count","regr_intercept","regr_r2","regr_slope","regr_sxx","regr_sxy","regr_syy","right","row_security_active","row_to_json","rpad","scale","set_masklen","setseed","setval","setweight","shobj_description","sind","sprintf","statement_timestamp","stddev","string_agg","string_to_array","strip","substr","table_to_xml","table_to_xml_and_xmlschema","tand","text","to_json","to_regclass","to_regnamespace","to_regoper","to_regoperator","to_regproc","to_regprocedure","to_regrole","to_regtype","to_tsquery","to_tsvector","transaction_timestamp","ts_debug","ts_delete","ts_filter","ts_headline","ts_lexize","ts_parse","ts_rank","ts_rank_cd","ts_rewrite","ts_stat","ts_token_type","tsquery_phrase","tsvector_to_array","tsvector_update_trigger","tsvector_update_trigger_column","txid_current","txid_current_snapshot","txid_snapshot_xip","txid_snapshot_xmax","txid_snapshot_xmin","txid_visible_in_snapshot","unnest","upper_inc","upper_inf","variance","width","width_bucket","xml_is_well_formed","xml_is_well_formed_content","xml_is_well_formed_document","xmlagg","xmlcomment","xmlconcat","xmlelement","xmlexists","xmlforest","xmlparse","xmlpi","xmlroot","xmlserialize","xpath","xpath_exists"],builtinVariables:[],pseudoColumns:[],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@keywords":"keyword","@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],complexIdentifiers:[[/"/,{token:"identifier.quote",next:"@quotedIdentifier"}]],quotedIdentifier:[[/[^"]+/,"identifier"],[/""/,"identifier"],[/"/,{token:"identifier.quote",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2350.a7af0a2e.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/23702.887336e8.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2350.a7af0a2e.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/23702.887336e8.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/2372.880a31f6.chunk.js b/ydb/core/viewer/monitoring/static/js/2372.880a31f6.chunk.js deleted file mode 100644 index 129bede95a8a..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2372.880a31f6.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2372.880a31f6.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2372],{22372:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>d,language:()=>f});var r,s,i=n(80781),o=Object.defineProperty,l=Object.getOwnPropertyDescriptor,a=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,p=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let s of a(t))c.call(e,s)||s===n||o(e,s,{get:()=>t[s],enumerable:!(r=l(t,s))||r.enumerable});return e},g={};p(g,r=i,"default"),s&&p(s,r,"default");var d={comments:{lineComment:"#",blockComment:["'''","'''"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],onEnterRules:[{beforeText:new RegExp("^\\s*(?:def|class|for|if|elif|else|while|try|with|finally|except|async|match|case).*?:\\s*$"),action:{indentAction:g.languages.IndentAction.Indent}}],folding:{offSide:!0,markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},f={defaultToken:"",tokenPostfix:".python",keywords:["False","None","True","_","and","as","assert","async","await","break","case","class","continue","def","del","elif","else","except","exec","finally","for","from","global","if","import","in","is","lambda","match","nonlocal","not","or","pass","print","raise","return","try","type","while","with","yield","int","float","long","complex","hex","abs","all","any","apply","basestring","bin","bool","buffer","bytearray","callable","chr","classmethod","cmp","coerce","compile","complex","delattr","dict","dir","divmod","enumerate","eval","execfile","file","filter","format","frozenset","getattr","globals","hasattr","hash","help","id","input","intern","isinstance","issubclass","iter","len","locals","list","map","max","memoryview","min","next","object","oct","open","ord","pow","print","property","reversed","range","raw_input","reduce","reload","repr","reversed","round","self","set","setattr","slice","sorted","staticmethod","str","sum","super","tuple","type","unichr","unicode","vars","xrange","zip","__dict__","__methods__","__members__","__class__","__bases__","__name__","__mro__","__subclasses__","__init__","__import__"],brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"}],tokenizer:{root:[{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},[/[,:;]/,"delimiter"],[/[{}\[\]()]/,"@brackets"],[/@[a-zA-Z_]\w*/,"tag"],[/[a-zA-Z_]\w*/,{cases:{"@keywords":"keyword","@default":"identifier"}}]],whitespace:[[/\s+/,"white"],[/(^#.*$)/,"comment"],[/'''/,"string","@endDocString"],[/"""/,"string","@endDblDocString"]],endDocString:[[/[^']+/,"string"],[/\\'/,"string"],[/'''/,"string","@popall"],[/'/,"string"]],endDblDocString:[[/[^"]+/,"string"],[/\\"/,"string"],[/"""/,"string","@popall"],[/"/,"string"]],numbers:[[/-?0x([abcdef]|[ABCDEF]|\d)+[lL]?/,"number.hex"],[/-?(\d*\.)?\d+([eE][+\-]?\d+)?[jJ]?[lL]?/,"number"]],strings:[[/'$/,"string.escape","@popall"],[/f'{1,3}/,"string.escape","@fStringBody"],[/'/,"string.escape","@stringBody"],[/"$/,"string.escape","@popall"],[/f"{1,3}/,"string.escape","@fDblStringBody"],[/"/,"string.escape","@dblStringBody"]],fStringBody:[[/[^\\'\{\}]+$/,"string","@popall"],[/[^\\'\{\}]+/,"string"],[/\{[^\}':!=]+/,"identifier","@fStringDetail"],[/\\./,"string"],[/'/,"string.escape","@popall"],[/\\$/,"string"]],stringBody:[[/[^\\']+$/,"string","@popall"],[/[^\\']+/,"string"],[/\\./,"string"],[/'/,"string.escape","@popall"],[/\\$/,"string"]],fDblStringBody:[[/[^\\"\{\}]+$/,"string","@popall"],[/[^\\"\{\}]+/,"string"],[/\{[^\}':!=]+/,"identifier","@fStringDetail"],[/\\./,"string"],[/"/,"string.escape","@popall"],[/\\$/,"string"]],dblStringBody:[[/[^\\"]+$/,"string","@popall"],[/[^\\"]+/,"string"],[/\\./,"string"],[/"/,"string.escape","@popall"],[/\\$/,"string"]],fStringDetail:[[/[:][^}]+/,"string"],[/[!][ars]/,"string"],[/=/,"string"],[/\}/,"identifier","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/23779.964f79d5.chunk.js b/ydb/core/viewer/monitoring/static/js/23779.964f79d5.chunk.js new file mode 100644 index 000000000000..b797effcc8cb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/23779.964f79d5.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[23779],{6170:(e,s,t)=>{t.d(s,{B:()=>c});var r=t(59284),a=t(73633),l=t(84375),n=t(99991);const o=(0,t(98192).om)("help-popover"),i=16;function c(e){var s;return r.createElement(l.A,Object.assign({},e,{className:o(null,e.className)}),r.createElement("button",Object.assign({ref:e.buttonRef,type:"button"},e.buttonProps,{className:o("button",null===(s=e.buttonProps)||void 0===s?void 0:s.className)}),r.createElement(n.I,{data:a.A,size:i})))}},10662:(e,s,t)=>{t.d(s,{i:()=>n});var r=t(28664),a=t(59284);var l=t(60712);const n=({onUpdate:e,value:s="",debounce:t=200,...n})=>{const[o,i]=function({value:e,onUpdate:s,debounce:t=200}){const[r,l]=a.useState(e),n=a.useRef();return a.useEffect((()=>{l((s=>s!==e?e:s))}),[e]),[r,e=>{l(e),window.clearTimeout(n.current),n.current=window.setTimeout((()=>{null===s||void 0===s||s(e)}),t)}]}({value:s,onUpdate:e,debounce:t});return(0,l.jsx)(r.k,{value:o,onUpdate:i,...n})}},15132:(e,s,t)=>{t.d(s,{O:()=>v});var r=t(38501),a=t(77506),l=t(56839),n=t(35736),o=t(41650),i=t(60712);const c=(0,a.cn)("progress-viewer"),d=e=>(0,l.ZV)((0,l.CR)(Number(e),2)),u=(e,s)=>[d(e),d(s)];function v({value:e,capacity:s,formatValues:t=u,percents:a,className:l,size:d="xs",colorizeProgress:v,inverseColorize:m,warningThreshold:h,dangerThreshold:N,hideCapacity:p}){const g=(0,r.D)();let f=Math.floor(parseFloat(String(e))/parseFloat(String(s))*100)||0;f=f>100?100:f;let S=e,b=s,x="/";a?(S=f+"%",b="",x=""):t&&([S,b]=t(Number(e),Number(s)));const E=(0,n.w)({fillWidth:f,warningThreshold:h,dangerThreshold:N,colorizeProgress:v,inverseColorize:m});v&&!(0,o.kf)(s)&&(f=100);const j={width:f+"%"};return(0,o.kf)(e)?(0,i.jsxs)("div",{className:c({size:d,theme:g,status:E},l),children:[(0,i.jsx)("div",{className:c("line"),style:j}),(0,i.jsx)("span",{className:c("text"),children:(0,o.kf)(s)&&!p?`${S} ${x} ${b}`:S})]}):(0,i.jsx)("div",{className:`${c({size:d})} ${l} error`,children:"no data"})}},18143:(e,s,t)=>{t.d(s,{k:()=>u});var r=t(59284);const a=(0,t(69220).om)("progress");function l(e){const{text:s,offset:t=0}=e;return s?r.createElement("div",{className:a("text-inner"),style:{transform:`translateX(calc(var(--g-flow-direction) * ${-t}%))`}},s):null}function n({item:e}){const{value:s,color:t,className:l,theme:n,title:o,content:i,loading:c}=e,d={loading:c};return"undefined"===typeof t&&(d.theme=n||"default"),Number.isFinite(s)?r.createElement("div",{className:a("item",d,l),style:{width:`${s}%`,backgroundColor:t},title:o},i):null}function o(e){return e<100?e-100:0}function i(e){const{theme:s,colorStops:t,colorStopsValue:r,value:a}=e;if(t){const e=t.find(((e,s)=>{const l="number"===typeof r?r:a,n=s>1?t[s-1].stop:0,o=s=n&&l<=o}));return e?e.theme:s}return s}function c(e){const{stack:s,stackClassName:t,value:i,text:c}=e,d=o(i||function(e){return e.reduce(((e,{value:s})=>e+s),0)}(s));return r.createElement("div",{className:a("stack",t),style:{transform:`translateX(calc(var(--g-flow-direction) * ${d}%))`}},r.createElement("div",{className:a("item"),style:{width:-d+"%"}}),s.map(((e,s)=>r.createElement(n,{key:s,item:e}))),r.createElement(l,{offset:d,text:c}))}function d(e){const{value:s,loading:t,text:n}=e,c=o(s);return Number.isFinite(s)?r.createElement("div",{className:a("item",{theme:i(e),loading:t}),style:{transform:`translateX(calc(var(--g-flow-direction) * ${c}%))`}},r.createElement(l,{offset:c,text:n})):null}const u=r.forwardRef((function(e,s){const{text:t="",theme:l="default",size:n="m",loading:o=!1,className:i,qa:u}=e,v=Object.assign(Object.assign({},e),{text:t,theme:l,size:n,loading:o});return r.createElement("div",{ref:s,className:a({size:n},i),"data-qa":u},r.createElement("div",{className:a("text")},t),function(e){return void 0!==e.stack}(v)?r.createElement(c,Object.assign({},v)):r.createElement(d,Object.assign({},v)))}))},35736:(e,s,t)=>{t.d(s,{w:()=>a});var r=t(76086);function a({inverseColorize:e,warningThreshold:s=r.Hh,dangerThreshold:t=r.Ed,colorizeProgress:a,fillWidth:l}){let n=e?"danger":"good";return a&&(l>s&&l<=t?n="warning":l>t&&(n=e?"good":"danger")),n}},41775:(e,s,t)=>{t.d(s,{v:()=>o});t(59284);var r=t(77506),a=t(10662),l=t(60712);const n=(0,r.cn)("ydb-search"),o=({onChange:e,value:s="",width:t,className:r,debounce:o,placeholder:i,inputRef:c})=>(0,l.jsx)(a.i,{debounce:o,hasClear:!0,autoFocus:!0,controlRef:c,style:{width:t},className:n(null,r),placeholder:i,value:s,onUpdate:e})},43951:(e,s,t)=>{t.d(s,{K:()=>l});var r=t(59284),a=t(59001);const l=(e,s,t,l,n)=>{const[o,i]=r.useState((()=>a.f.readUserSettingsValue(s,l)));return{columnsToShow:r.useMemo((()=>e.filter((e=>{const s=e.name,t=o.includes(s),r=null===n||void 0===n?void 0:n.includes(s);return t||r}))),[e,n,o]),columnsToSelect:r.useMemo((()=>e.map((e=>e.name)).map((e=>{const s=null===n||void 0===n?void 0:n.includes(e),r=o.includes(e);return{id:e,title:t[e],selected:s||r,required:s,sticky:s?"start":void 0}}))),[e,t,n,o]),setColumns:r.useCallback((e=>{const t=e.filter((e=>e.selected)).map((e=>e.id));a.f.setUserSettingsValue(s,t),i(t)}),[s])}}},48288:(e,s,t)=>{t.r(s),t.d(s,{Clusters:()=>te});var r=t(59284),a=t(4557),l=t(24555),n=t(69775),o=t(61750),i=t(90053),c=t(44508),d=t(52248),u=t(17594),v=t(95963),m=t(39567),h=t(23536),N=t.n(h),p=t(41650);const g=e=>e.clusters.clusterName,f=e=>e.clusters.status,S=e=>e.clusters.service,b=e=>e.clusters.version,x=(e,s)=>0===s.length||e.status&&s.includes(e.status),E=(e,s)=>0===s.length||e.service&&s.includes(e.service),j=(e,s)=>0===s.length||s.some((s=>{var t,r;return null===(t=e.cluster)||void 0===t||null===(r=t.Versions)||void 0===r?void 0:r.some((e=>e.startsWith(s)))})),T=(e,s="")=>{var t;if(!s)return!0;const r=s.toLowerCase(),a=r.split(" "),l=(null===(t=e.title)||void 0===t?void 0:t.toLowerCase().match(/[^\d\s]+|\d+|[^-\s]+|[^_\s]+/g))||[],n=a.every((s=>{const t=N()(s),r=new RegExp(`^${t}|[\\s\\-_]${t}`,"i");return e.title&&r.test(e.title)||l.some((e=>e.startsWith(s)))})),o=e.preparedVersions.some((e=>e.version.includes(r))),i=Boolean(e.hosts&&e.hosts[r]);return n||o||i};var O=t(76086),C=t(90182),w=t(43951),A=t(38596),_=t(15132),y=t(56839),R=t(48372);const I=JSON.parse('{"controls_status-select-label":"Status:","controls_service-select-label":"Service:","controls_version-select-label":"Version:","controls_search-placeholder":"Cluster name, version, host","controls_select-placeholder":"All","statistics_clusters":"Clusters","statistics_hosts":"Hosts","statistics_tenants":"Tenants","statistics_nodes":"Nodes","statistics_load":"Load","statistics_storage":"Storage","tooltip_no-cluster-data":"No cluster data","page_title":"Clusters"}'),D=JSON.parse('{"controls_status-select-label":"\u0421\u0442\u0430\u0442\u0443\u0441:","controls_service-select-label":"\u0421\u0435\u0440\u0432\u0438\u0441:","controls_version-select-label":"\u0412\u0435\u0440\u0441\u0438\u044f:","controls_search-placeholder":"\u0418\u043c\u044f \u043a\u043b\u0430\u0441\u0442\u0435\u0440\u0430, \u0432\u0435\u0440\u0441\u0438\u044f \u0438\u043b\u0438 \u0445\u043e\u0441\u0442","controls_select-placeholder":"\u0412\u0441\u0435","statistics_clusters":"\u041a\u043b\u0430\u0441\u0442\u0435\u0440\u044b","statistics_hosts":"\u0425\u043e\u0441\u0442\u044b","statistics_tenants":"\u0411\u0430\u0437\u044b \u0434\u0430\u043d\u043d\u044b\u0445","statistics_nodes":"\u0423\u0437\u043b\u044b","statistics_load":"\u041d\u0430\u0433\u0440\u0443\u0437\u043a\u0430","statistics_storage":"\u0425\u0440\u0430\u043d\u0438\u043b\u0438\u0449\u0435","tooltip_no-cluster-data":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445 \u043a\u043b\u0430\u0441\u0442\u0435\u0440\u0430","page_title":"\u041a\u043b\u0430\u0441\u0442\u0435\u0440\u044b"}'),L=(0,R.g4)("ydb-clusters-page",{ru:D,en:I});var k=t(77506);const z=(0,k.cn)("clusters");var U=t(60712);const V=({count:e,stats:s})=>{const{NodesTotal:t,NodesAlive:r,Hosts:a,Tenants:l,LoadAverage:n,NumberOfCpus:o,StorageUsed:i,StorageTotal:c}=s;return(0,U.jsxs)("div",{className:z("aggregation"),children:[(0,U.jsxs)("div",{className:z("aggregation-value-container"),children:[(0,U.jsx)("span",{className:z("aggregation-label"),children:L("statistics_clusters")}),e]}),(0,U.jsxs)("div",{className:z("aggregation-value-container"),children:[(0,U.jsx)("span",{className:z("aggregation-label"),children:L("statistics_hosts")}),a]}),(0,U.jsxs)("div",{className:z("aggregation-value-container"),children:[(0,U.jsx)("span",{className:z("aggregation-label"),children:L("statistics_tenants")}),l]}),(0,U.jsxs)("div",{className:z("aggregation-value-container"),children:[(0,U.jsx)("span",{className:z("aggregation-label"),children:L("statistics_nodes")}),(0,U.jsx)(_.O,{size:"ns",value:r,capacity:t,colorizeProgress:!0,inverseColorize:!0})]}),(0,U.jsxs)("div",{className:z("aggregation-value-container"),children:[(0,U.jsx)("span",{className:z("aggregation-label"),children:L("statistics_load")}),(0,U.jsx)(_.O,{size:"ns",value:n,capacity:o,colorizeProgress:!0})]}),(0,U.jsxs)("div",{className:z("aggregation-value-container"),children:[(0,U.jsx)("span",{className:z("aggregation-label"),children:L("statistics_storage")}),(0,U.jsx)(_.O,{size:"ns",value:i,capacity:c,formatValues:y.j9,colorizeProgress:!0})]})]})};var B=t(6170),W=t(67884),G=t(18143),M=t(96873),P=t(34271);const $=(0,k.cn)("kv-user");function H({login:e,className:s}){const t=(0,P.x)("StaffCard");return(0,U.jsx)("div",{className:$(null,s),children:(0,U.jsx)(t,{login:e,children:(0,U.jsx)("div",{className:$("name"),children:e})})})}var F=t(31684),q=t(69446),J=t(87842);const K="selectedColumns",Q={TITLE:"title",VERSIONS:"versions",DC:"dc",SERVICE:"service",STATUS:"status",NODES:"nodes",LOAD:"load",STORAGE:"storage",HOSTS:"hosts",TENANTS:"tenants",OWNER:"owner",DESCRIPTION:"description",BALANCER:"balancer"},X=[Q.TITLE,Q.VERSIONS,Q.SERVICE,Q.STATUS,Q.NODES,Q.LOAD,Q.STORAGE,Q.HOSTS,Q.TENANTS,Q.OWNER,Q.BALANCER],Y={[Q.TITLE]:"Cluster",[Q.VERSIONS]:"Versions",[Q.DC]:"DC",[Q.SERVICE]:"Service",[Q.STATUS]:"Status",[Q.NODES]:"Nodes",[Q.LOAD]:"Load",[Q.STORAGE]:"Storage",[Q.HOSTS]:"Hosts",[Q.TENANTS]:"Tenants",[Q.OWNER]:"Owner",[Q.DESCRIPTION]:"Description",[Q.BALANCER]:"Balancer"},Z="clustersTableColumnsWidth",ee=(0,U.jsx)("span",{className:z("empty-cell"),children:"\u2014"}),se=[{name:Q.TITLE,header:Y[Q.TITLE],width:230,render:({row:e})=>{var s,t;const{name:r,use_embedded_ui:a,preparedBackend:l}=e,n=a&&l?(0,F.t1)(l):(0,J.a)(void 0,{backend:l,clusterName:r},{withBasename:!0}),o=null===(s=e.cluster)||void 0===s?void 0:s.Overall;return(0,U.jsxs)("div",{className:z("cluster"),children:[o?(0,U.jsx)(W.N,{href:n,children:(0,U.jsx)("div",{className:z("cluster-status",{type:o&&o.toLowerCase()})})}):(0,U.jsx)("div",{className:z("cluster-status"),children:(0,U.jsx)(B.B,{content:(0,U.jsx)("span",{className:z("tooltip-content"),children:(null===(t=e.cluster)||void 0===t?void 0:t.error)||L("tooltip_no-cluster-data")}),offset:{left:0}})}),(0,U.jsx)("div",{className:z("cluster-name"),children:(0,U.jsx)(W.N,{href:n,children:e.title})})]})},defaultOrder:a.Ay.ASCENDING},{name:Q.VERSIONS,header:Y[Q.VERSIONS],width:300,defaultOrder:a.Ay.DESCENDING,sortAccessor:({preparedVersions:e})=>e.map((e=>e.version.replace(/^[0-9]\+\./g,""))).sort(((e,s)=>e.localeCompare(s)))[0]||void 0,render:({row:e})=>{const{preparedVersions:s,versions:t=[],name:a,preparedBackend:l}=e;if(!t.length||t.some((e=>!e.version)))return ee;const n=t.reduce(((e,s)=>e+s.count),0),o=t.map((e=>{var t;return{value:e.count/n*100,color:null===(t=s.find((s=>s.version===e.version)))||void 0===t?void 0:t.color}}));return s.length>0&&(0,U.jsx)(W.N,{className:z("cluster-versions"),href:(0,J.a)(J.Bi.versions,{backend:l,clusterName:a},{withBasename:!0}),children:(0,U.jsxs)(r.Fragment,{children:[s.map(((e,s)=>(0,U.jsx)("div",{className:z("cluster-version"),style:{color:e.color},title:e.version,children:e.version},s))),(0,U.jsx)(G.k,{size:"s",value:100,stack:o})]})})}},{name:Q.DC,header:Y[Q.DC],width:120,sortable:!1,render:({row:e})=>{const s=e.cluster&&e.cluster.DataCenters||[];return(0,U.jsx)("div",{className:z("cluster-dc"),children:s.join(", ")||ee})}},{name:Q.SERVICE,header:Y[Q.SERVICE],width:100,sortable:!0},{name:Q.STATUS,header:Y[Q.STATUS],width:150,sortable:!0},{name:Q.NODES,header:Y[Q.NODES],resizeMinWidth:170,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e={}})=>{const{NodesTotal:s=0}=e;return s},render:({row:e})=>{const{NodesAlive:s=0,NodesTotal:t=0,Overall:r}=e.cluster||{};return r?(0,U.jsx)(_.O,{value:s,capacity:t}):ee}},{name:Q.LOAD,header:Y[Q.LOAD],resizeMinWidth:170,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>null===e||void 0===e?void 0:e.NumberOfCpus,render:({row:e})=>{const{LoadAverage:s=0,NumberOfCpus:t=0,RealNumberOfCpus:r,Overall:a}=e.cluster||{};return a?(0,U.jsx)(_.O,{value:s,capacity:null!==r&&void 0!==r?r:t}):ee}},{name:Q.STORAGE,header:Y[Q.STORAGE],resizeMinWidth:170,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>Number(null===e||void 0===e?void 0:e.StorageTotal),render:({row:e})=>{const{StorageUsed:s=0,StorageTotal:t=0,Overall:r}=e.cluster||{};return r?(0,U.jsx)(_.O,{value:s,capacity:t,formatValues:y.ki}):ee}},{name:Q.HOSTS,header:Y[Q.HOSTS],width:80,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>Number(null===e||void 0===e?void 0:e.Hosts)||0,render:({row:e})=>{var s;return Number(null===(s=e.cluster)||void 0===s?void 0:s.Hosts)||ee}},{name:Q.TENANTS,header:Y[Q.TENANTS],width:80,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>Number(null===e||void 0===e?void 0:e.Tenants)||0,render:({row:e})=>{var s;return Number(null===(s=e.cluster)||void 0===s?void 0:s.Tenants)||ee}},{name:Q.OWNER,header:Y[Q.OWNER],sortable:!1,width:120,render:({row:e})=>{var s;const t=null===(s=e.owner)||void 0===s?void 0:s.split(", ");return null!==t&&void 0!==t&&t.length?t.map((e=>(0,U.jsx)(H,{login:e},e))):ee}},{name:Q.DESCRIPTION,header:Y[Q.DESCRIPTION],sortable:!1,width:150,render:({row:e})=>e.description?(0,U.jsx)("div",{className:z("description"),children:e.description}):ee},{name:Q.BALANCER,header:Y[Q.BALANCER],sortable:!1,width:290,render:({row:e})=>{if(!e.balancer)return ee;const s=(0,q.Zd)(e.balancer);return(0,U.jsxs)("div",{className:z("balancer-cell"),children:[(0,U.jsx)("div",{className:z("balancer-text"),children:s}),(0,U.jsx)(M.b,{size:"s",text:s,className:z("balancer-icon")})]})}}];function te(){const[e]=(0,C.Nt)(),s=m.ub.useGetClustersListQuery(void 0,{pollingInterval:e}),t=(0,C.YQ)(),h=(0,C.N4)(g),N=(0,C.N4)(f),_=(0,C.N4)(S),y=(0,C.N4)(b),{columnsToShow:R,columnsToSelect:I,setColumns:D}=(0,w.K)(se,K,Y,X,[Q.TITLE]),k=s.data,{servicesToSelect:B,versions:W}=r.useMemo((()=>{const e=new Set,s=new Set;return(null!==k&&void 0!==k?k:[]).forEach((t=>{var r,a;t.service&&e.add(t.service),null===(r=t.cluster)||void 0===r||null===(a=r.Versions)||void 0===a||a.forEach((e=>{s.add((0,A.U)(e))}))})),{servicesToSelect:Array.from(e).map((e=>({value:e,content:e}))),versions:Array.from(s).map((e=>({value:e,content:e})))}}),[k]),G=r.useMemo((()=>function(e,s){return e.filter((e=>x(e,s.status)&&E(e,s.service)&&j(e,s.version)&&T(e,s.clusterName)))}(null!==k&&void 0!==k?k:[],{clusterName:h,status:N,service:_,version:y})),[h,k,_,N,y]),M=r.useMemo((()=>function(e){let s=0,t=0,r=0,a=0,l=0,n=0,o=0;const i=new Set;return e.filter((({cluster:e})=>!(null!==e&&void 0!==e&&e.error))).forEach((({cluster:e,hosts:c={}})=>{s+=(null===e||void 0===e?void 0:e.NodesTotal)||0,t+=(null===e||void 0===e?void 0:e.NodesAlive)||0,Object.keys(c).forEach((e=>i.add(e))),o+=Number(null===e||void 0===e?void 0:e.Tenants)||0,r+=Number(null===e||void 0===e?void 0:e.LoadAverage)||0,a+=(0,p.kf)(null===e||void 0===e?void 0:e.RealNumberOfCpus)?null===e||void 0===e?void 0:e.RealNumberOfCpus:(null===e||void 0===e?void 0:e.NumberOfCpus)||0,l+=null!==e&&void 0!==e&&e.StorageUsed?Math.floor(parseInt(e.StorageUsed,10)):0,n+=null!==e&&void 0!==e&&e.StorageTotal?Math.floor(parseInt(e.StorageTotal,10)):0})),{NodesTotal:s,NodesAlive:t,Hosts:i.size,Tenants:o,LoadAverage:r,NumberOfCpus:a,StorageUsed:l,StorageTotal:n}}(G)),[G]),P=r.useMemo((()=>Array.from(new Set((null!==k&&void 0!==k?k:[]).map((e=>e.status)).filter(Boolean))).sort().map((e=>({value:e,content:e})))),[k]);return(0,U.jsxs)("div",{className:z(),children:[(0,U.jsx)(o.mg,{children:(0,U.jsx)("title",{children:L("page_title")})}),(0,U.jsx)(V,{stats:M,count:G.length}),(0,U.jsxs)("div",{className:z("controls"),children:[(0,U.jsx)("div",{className:z("control",{wide:!0}),children:(0,U.jsx)(v.v,{placeholder:L("controls_search-placeholder"),onChange:e=>{t((0,m.Fe)({clusterName:e}))},value:h})}),(0,U.jsx)("div",{className:z("control"),children:(0,U.jsx)(l.l,{multiple:!0,filterable:!0,hasClear:!0,placeholder:L("controls_select-placeholder"),label:L("controls_status-select-label"),value:N,options:P,onUpdate:e=>{t((0,m.Fe)({status:e}))},width:"max"})}),(0,U.jsx)("div",{className:z("control"),children:(0,U.jsx)(l.l,{multiple:!0,filterable:!0,hasClear:!0,placeholder:L("controls_select-placeholder"),label:L("controls_service-select-label"),value:_,options:B,onUpdate:e=>{t((0,m.Fe)({service:e}))},width:"max"})}),(0,U.jsx)("div",{className:z("control"),children:(0,U.jsx)(l.l,{multiple:!0,filterable:!0,hasClear:!0,placeholder:L("controls_select-placeholder"),label:L("controls_version-select-label"),value:y,options:W,onUpdate:e=>{t((0,m.Fe)({version:e}))},width:"max"})}),(0,U.jsx)("div",{className:z("control"),children:(0,U.jsx)(n.O,{popupWidth:242,items:I,showStatus:!0,onUpdate:D,sortable:!1},"TableColumnSetup")}),(0,U.jsx)(i.E,{className:z("autorefresh")})]}),s.isError?(0,U.jsx)(c.o,{error:s.error,className:z("error")}):null,s.isLoading?(0,U.jsx)(d.a,{size:"l"}):null,s.fulfilledTimeStamp?(0,U.jsx)("div",{className:z("table-wrapper"),children:(0,U.jsx)("div",{className:z("table-content"),children:(0,U.jsx)(u.l,{columnsWidthLSKey:Z,wrapperClassName:z("table"),data:G,columns:R,settings:{...O.N3,dynamicRender:!1},initialSortOrder:{columnId:Q.TITLE,order:a.Ay.ASCENDING}})})}):null]})}},52248:(e,s,t)=>{t.d(s,{a:()=>r.a});var r=t(47334)},90053:(e,s,t)=>{t.d(s,{E:()=>h});var r=t(8873),a=t(84476),l=t(24555),n=t(21334),o=t(77506),i=t(90182),c=t(48372);const d=JSON.parse('{"None":"None","15 sec":"15 sec","1 min":"1 min","2 min":"2 min","5 min":"5 min","Refresh":"Refresh"}'),u=(0,c.g4)("ydb-diagnostics-autorefresh-control",{en:d});var v=t(60712);const m=(0,o.cn)("auto-refresh-control");function h({className:e,onManualRefresh:s}){const t=(0,i.YQ)(),[o,c]=(0,i.Nt)();return(0,v.jsxs)("div",{className:m(null,e),children:[(0,v.jsx)(a.$,{view:"flat-secondary",onClick:()=>{t(n.F.util.invalidateTags(["All"])),null===s||void 0===s||s()},extraProps:{"aria-label":u("Refresh")},children:(0,v.jsx)(a.$.Icon,{children:(0,v.jsx)(r.A,{})})}),(0,v.jsxs)(l.l,{value:[String(o)],onUpdate:e=>{c(Number(e))},width:85,qa:"ydb-autorefresh-select",children:[(0,v.jsx)(l.l.Option,{value:"0",children:u("None")}),(0,v.jsx)(l.l.Option,{value:"15000",children:u("15 sec")}),(0,v.jsx)(l.l.Option,{value:"60000",children:u("1 min")}),(0,v.jsx)(l.l.Option,{value:"120000",children:u("2 min")}),(0,v.jsx)(l.l.Option,{value:"300000",children:u("5 min")})]})]})}},95963:(e,s,t)=>{t.d(s,{v:()=>r.v});var r=t(41775)},98192:(e,s,t)=>{t.d(s,{CU:()=>a,om:()=>l});var r=t(82435);const a="gc-",l=((0,r.withNaming)({e:"__",m:"_",v:"_"}),(0,r.withNaming)({n:a,e:"__",m:"_",v:"_"}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/23882.3b39c413.chunk.js b/ydb/core/viewer/monitoring/static/js/23882.3b39c413.chunk.js new file mode 100644 index 000000000000..b5cdf993b375 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/23882.3b39c413.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[23882],{23882:(e,r,n)=>{n.d(r,{default:()=>a});var t=n(58151);const a=n.n(t)()},58151:(e,r,n)=>{var t=n(77831);function a(e){e.register(t),function(e){for(var r=/\((?:[^();"#\\]|\\[\s\S]|;.*(?!.)|"(?:[^"\\]|\\.)*"|#(?:\{(?:(?!#\})[\s\S])*#\}|[^{])|)*\)/.source,n=0;n<5;n++)r=r.replace(//g,(function(){return r}));r=r.replace(//g,/[^\s\S]/.source);var t=e.languages.lilypond={comment:/%(?:(?!\{).*|\{[\s\S]*?%\})/,"embedded-scheme":{pattern:RegExp(/(^|[=\s])#(?:"(?:[^"\\]|\\.)*"|[^\s()"]*(?:[^\s()]|))/.source.replace(//g,(function(){return r})),"m"),lookbehind:!0,greedy:!0,inside:{scheme:{pattern:/^(#)[\s\S]+$/,lookbehind:!0,alias:"language-scheme",inside:{"embedded-lilypond":{pattern:/#\{[\s\S]*?#\}/,greedy:!0,inside:{punctuation:/^#\{|#\}$/,lilypond:{pattern:/[\s\S]+/,alias:"language-lilypond",inside:null}}},rest:e.languages.scheme}},punctuation:/#/}},string:{pattern:/"(?:[^"\\]|\\.)*"/,greedy:!0},"class-name":{pattern:/(\\new\s+)[\w-]+/,lookbehind:!0},keyword:{pattern:/\\[a-z][-\w]*/i,inside:{punctuation:/^\\/}},operator:/[=|]|<<|>>/,punctuation:{pattern:/(^|[a-z\d])(?:'+|,+|[_^]?-[_^]?(?:[-+^!>._]|(?=\d))|[_^]\.?|[.!])|[{}()[\]<>^~]|\\[()[\]<>\\!]|--|__/,lookbehind:!0},number:/\b\d+(?:\/\d+)?\b/};t["embedded-scheme"].inside.scheme.inside["embedded-lilypond"].inside.lilypond.inside=t,e.languages.ly=t}(e)}e.exports=a,a.displayName="lilypond",a.aliases=[]},77831:e=>{function r(e){!function(e){e.languages.scheme={comment:/;.*|#;\s*(?:\((?:[^()]|\([^()]*\))*\)|\[(?:[^\[\]]|\[[^\[\]]*\])*\])|#\|(?:[^#|]|#(?!\|)|\|(?!#)|#\|(?:[^#|]|#(?!\|)|\|(?!#))*\|#)*\|#/,string:{pattern:/"(?:[^"\\]|\\.)*"/,greedy:!0},symbol:{pattern:/'[^()\[\]#'\s]+/,greedy:!0},char:{pattern:/#\\(?:[ux][a-fA-F\d]+\b|[-a-zA-Z]+\b|[\uD800-\uDBFF][\uDC00-\uDFFF]|\S)/,greedy:!0},"lambda-parameter":[{pattern:/((?:^|[^'`#])[(\[]lambda\s+)(?:[^|()\[\]'\s]+|\|(?:[^\\|]|\\.)*\|)/,lookbehind:!0},{pattern:/((?:^|[^'`#])[(\[]lambda\s+[(\[])[^()\[\]']+/,lookbehind:!0}],keyword:{pattern:/((?:^|[^'`#])[(\[])(?:begin|case(?:-lambda)?|cond(?:-expand)?|define(?:-library|-macro|-record-type|-syntax|-values)?|defmacro|delay(?:-force)?|do|else|except|export|guard|if|import|include(?:-ci|-library-declarations)?|lambda|let(?:rec)?(?:-syntax|-values|\*)?|let\*-values|only|parameterize|prefix|(?:quasi-?)?quote|rename|set!|syntax-(?:case|rules)|unless|unquote(?:-splicing)?|when)(?=[()\[\]\s]|$)/,lookbehind:!0},builtin:{pattern:/((?:^|[^'`#])[(\[])(?:abs|and|append|apply|assoc|ass[qv]|binary-port\?|boolean=?\?|bytevector(?:-append|-copy|-copy!|-length|-u8-ref|-u8-set!|\?)?|caar|cadr|call-with-(?:current-continuation|port|values)|call\/cc|car|cdar|cddr|cdr|ceiling|char(?:->integer|-ready\?|\?|<\?|<=\?|=\?|>\?|>=\?)|close-(?:input-port|output-port|port)|complex\?|cons|current-(?:error|input|output)-port|denominator|dynamic-wind|eof-object\??|eq\?|equal\?|eqv\?|error|error-object(?:-irritants|-message|\?)|eval|even\?|exact(?:-integer-sqrt|-integer\?|\?)?|expt|features|file-error\?|floor(?:-quotient|-remainder|\/)?|flush-output-port|for-each|gcd|get-output-(?:bytevector|string)|inexact\??|input-port(?:-open\?|\?)|integer(?:->char|\?)|lcm|length|list(?:->string|->vector|-copy|-ref|-set!|-tail|\?)?|make-(?:bytevector|list|parameter|string|vector)|map|max|member|memq|memv|min|modulo|negative\?|newline|not|null\?|number(?:->string|\?)|numerator|odd\?|open-(?:input|output)-(?:bytevector|string)|or|output-port(?:-open\?|\?)|pair\?|peek-char|peek-u8|port\?|positive\?|procedure\?|quotient|raise|raise-continuable|rational\?|rationalize|read-(?:bytevector|bytevector!|char|error\?|line|string|u8)|real\?|remainder|reverse|round|set-c[ad]r!|square|string(?:->list|->number|->symbol|->utf8|->vector|-append|-copy|-copy!|-fill!|-for-each|-length|-map|-ref|-set!|\?|<\?|<=\?|=\?|>\?|>=\?)?|substring|symbol(?:->string|\?|=\?)|syntax-error|textual-port\?|truncate(?:-quotient|-remainder|\/)?|u8-ready\?|utf8->string|values|vector(?:->list|->string|-append|-copy|-copy!|-fill!|-for-each|-length|-map|-ref|-set!|\?)?|with-exception-handler|write-(?:bytevector|char|string|u8)|zero\?)(?=[()\[\]\s]|$)/,lookbehind:!0},operator:{pattern:/((?:^|[^'`#])[(\[])(?:[-+*%/]|[<>]=?|=>?)(?=[()\[\]\s]|$)/,lookbehind:!0},number:{pattern:RegExp(function(e){for(var r in e)e[r]=e[r].replace(/<[\w\s]+>/g,(function(r){return"(?:"+e[r].trim()+")"}));return e[r]}({"":/\d+(?:\/\d+)|(?:\d+(?:\.\d*)?|\.\d+)(?:[esfdl][+-]?\d+)?/.source,"":/[+-]?|[+-](?:inf|nan)\.0/.source,"":/[+-](?:|(?:inf|nan)\.0)?i/.source,"":/(?:@|)?|/.source,"":/(?:#d(?:#[ei])?|#[ei](?:#d)?)?/.source,"":/[0-9a-f]+(?:\/[0-9a-f]+)?/.source,"":/[+-]?|[+-](?:inf|nan)\.0/.source,"":/[+-](?:|(?:inf|nan)\.0)?i/.source,"":/(?:@|)?|/.source,"":/#[box](?:#[ei])?|(?:#[ei])?#[box]/.source,"":/(^|[()\[\]\s])(?:|)(?=[()\[\]\s]|$)/.source}),"i"),lookbehind:!0},boolean:{pattern:/(^|[()\[\]\s])#(?:[ft]|false|true)(?=[()\[\]\s]|$)/,lookbehind:!0},function:{pattern:/((?:^|[^'`#])[(\[])(?:[^|()\[\]'\s]+|\|(?:[^\\|]|\\.)*\|)(?=[()\[\]\s]|$)/,lookbehind:!0},identifier:{pattern:/(^|[()\[\]\s])\|(?:[^\\|]|\\.)*\|(?=[()\[\]\s]|$)/,lookbehind:!0,greedy:!0},punctuation:/[()\[\]']/}}(e)}e.exports=r,r.displayName="scheme",r.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/24130.160bfd14.chunk.js b/ydb/core/viewer/monitoring/static/js/24130.160bfd14.chunk.js new file mode 100644 index 000000000000..b966bb8827fc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/24130.160bfd14.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[24130],{23536:(e,t,n)=>{var i=n(68814),s=/[\\^$.*+?()[\]{}|]/g,a=RegExp(s.source);e.exports=function(e){return(e=i(e))&&a.test(e)?e.replace(s,"\\$&"):e}},38501:(e,t,n)=>{"use strict";n.d(t,{D:()=>s});var i=n(46878);function s(){return(0,i.w)().theme}},69775:(e,t,n)=>{"use strict";n.d(t,{O:()=>Ce});var i=n(59284),s=n(27738),a=n(84476),d=n(99991),l=n(66821);const r=e=>i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),i.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M10.5 6V5a2.5 2.5 0 0 0-5 0v1zM4 5v1a3 3 0 0 0-3 3v3a3 3 0 0 0 3 3h8a3 3 0 0 0 3-3V9a3 3 0 0 0-3-3V5a4 4 0 0 0-8 0m6.5 2.5H12A1.5 1.5 0 0 1 13.5 9v3a1.5 1.5 0 0 1-1.5 1.5H4A1.5 1.5 0 0 1 2.5 12V9A1.5 1.5 0 0 1 4 7.5zm-1.75 2a.75.75 0 0 0-1.5 0v2a.75.75 0 0 0 1.5 0z",clipRule:"evenodd"}));var o=n(53202),c=n(90826),u=n(46734),m=n(98089),p=n(32084),I=n(51301),v=n(92609),b=n(19884),g=n(93628),f=n(27145),y=n(87184),h=n(69220);const x=(0,h.om)("list-container-view"),S=i.forwardRef((function({as:e="div",role:t="listbox",children:n,id:s,className:a,fixedHeight:d,extraProps:l,qa:r,style:o},c){return i.createElement(y.s,Object.assign({qa:r,as:e,direction:"column",ref:c,grow:!0,tabIndex:-1,id:s,role:t,style:o,className:x({"fixed-height":d},a)},l),n)})),B=e=>null!==e&&"object"===typeof e&&"data"in e,E=(0,h.om)("list-recursive-renderer");function C(e){var t,{id:n,itemSchema:s,list:a}=e,d=(0,f.Tt)(e,["id","itemSchema","list"]);const l=d.children(n,a.structure.idToFlattenIndex[n]);if(B(s)&&s.children){const e=!a.state.expandedById||!(n in a.state.expandedById)||a.state.expandedById[n];return i.createElement("ul",{style:d.style,className:E(null,d.className),role:"group"},l,e&&Boolean(null===(t=a.structure.groupsState[n])||void 0===t?void 0:t.childrenIds)&&s.children.map(((e,t)=>i.createElement(C,Object.assign({list:a,id:a.structure.groupsState[n].childrenIds[t],itemSchema:e,key:t},d)))))}return l}function O(e){var{containerRef:t,renderItem:n,list:s}=e,a=(0,f.Tt)(e,["containerRef","renderItem","list"]);return i.createElement(S,Object.assign({ref:t},a),s.structure.items.map(((e,t)=>i.createElement(C,{key:t,itemSchema:e,id:s.structure.rootIds[t],list:s},n))))}const w=({list:e,multiple:t})=>({id:n})=>{e.state.disabledById[n]||(e.state.setActiveItemId(n),e.state.expandedById&&n in e.state.expandedById&&e.state.setExpanded?e.state.setExpanded((e=>Object.assign(Object.assign({},e),{[n]:!e[n]}))):e.state.setSelected((e=>Object.assign(Object.assign({},t?e:{}),{[n]:!t||!e[n]}))))};var j=n(359);const k="data-list-item",N={s:[22,44],m:[26,44],l:[34,52],xl:[44,62]},R=({containerRef:e,onItemClick:t,enabled:n,list:s})=>{const a=i.useCallback(((t,n=!0)=>{var i,a;"number"===typeof t&&s.structure.visibleFlattenIds[t]&&(n&&((e,t)=>{var n;if(document){const i=(t||document).querySelector(`[${k}="${e}"]`);i&&(null===(n=i.scrollIntoView)||void 0===n||n.call(i,{block:"nearest"}))}})(s.structure.visibleFlattenIds[t],null===e||void 0===e?void 0:e.current),null===(a=(i=s.state).setActiveItemId)||void 0===a||a.call(i,s.structure.visibleFlattenIds[t]))}),[s.structure.visibleFlattenIds,s.state,e]),d=i.useCallback(((e,t,n=0)=>{e.preventDefault();const i="string"===typeof s.state.activeItemId?s.structure.visibleFlattenIds.findIndex((e=>e===s.state.activeItemId)):-1,d=(({list:e,index:t,step:n,disabledItemsById:i={}})=>{const s=e.length;let a=(t+s)%s;for(let d=0;d-1?i:n)+t,step:Math.sign(t),disabledItemsById:s.state.disabledById});a(d)}),[a,s.state.activeItemId,s.state.disabledById,s.structure.visibleFlattenIds]);i.useLayoutEffect((()=>{const i=null===e||void 0===e?void 0:e.current;if(n||!i)return;const a=e=>{switch(e.key){case j.D.ARROW_DOWN:d(e,1,-1);break;case j.D.ARROW_UP:d(e,-1);break;case j.D.SPACEBAR:case j.D.ENTER:s.state.activeItemId&&!s.state.disabledById[s.state.activeItemId]&&(e.preventDefault(),null===t||void 0===t||t({id:s.state.activeItemId}))}};return i.addEventListener("keydown",a),()=>{i.removeEventListener("keydown",a)}}),[e,n,d,s.state.activeItemId,s.state.disabledById,t])};var D=n(46423),F=n(25569),P=n(63365),T=n(33705);const $=(0,h.om)("list-item-expand-icon"),A=({expanded:e,behavior:t="action",disabled:n})=>i.createElement(T.I,{direction:z({behavior:t,expanded:e}),className:$(null,(0,P.$)({color:n?"hint":void 0})),size:16});function z({behavior:e,expanded:t}){return t&&"action"===e?"top":t&&"state"===e||t&&"state-inverse"===e||"action"===e?"bottom":"state"===e?"right":"state-inverse"===e?"left":"bottom"}const M=(0,h.om)("list-item-view"),L=e=>"object"===typeof e&&null!==e&&"title"in e,q=e=>{var{children:t,indentation:n=1,className:s}=e,a=(0,f.Tt)(e,["children","indentation","className"]);return i.createElement(y.s,Object.assign({width:16*n,className:M("slot",s)},a),t)},_=({startSlot:e,subtitle:t,endSlot:n,disabled:s,hasSelectionIcon:a,isGroup:l,indentation:r,expanded:o,selected:c,title:u,expandIconPlacement:p="start",renderExpandIcon:I=A})=>{const v=l?i.createElement(I,{behavior:"start"===p?"state":"action",expanded:o,disabled:s}):null;return i.createElement(y.s,{alignItems:"center",justifyContent:"space-between",gap:"4",className:M("content")},i.createElement(y.s,{gap:"2",alignItems:"center",grow:!0},a&&i.createElement(q,null,c?i.createElement(d.I,{data:F.A,size:16,className:(0,P.$)({color:"info"})}):null),(e=>e&&e>=1?i.createElement(q,{indentation:Math.floor(e)}):null)(r),"start"===p&&v,e,i.createElement("div",{className:M("main-content")},"string"===typeof u?i.createElement(m.E,{ellipsis:!0,color:s?"hint":void 0,variant:l?"subheader-1":void 0},u):u,"string"===typeof t?i.createElement(m.E,{ellipsis:!0,color:s?"hint":"secondary"},t):t)),i.createElement(y.s,{gap:"2"},"end"===p&&v,n))},V=i.forwardRef((function(e,t){var{id:n,as:s,size:a="m",active:d,selected:l,disabled:r,selectionViewType:o="multiple",activeOnHover:c,className:u,height:m,dragging:p,style:I,content:v,role:b="option",onClick:g}=e,y=(0,f.Tt)(e,["id","as","size","active","selected","disabled","selectionViewType","activeOnHover","className","height","dragging","style","content","role","onClick"]);const h=s||"li",x=r?void 0:g,S="boolean"===typeof c?c:Boolean(x),B=Object.assign({minHeight:`var(--g-list-item-height, ${null!==m&&void 0!==m?m:N[a][Number(Boolean(!!L(v)&&(null===v||void 0===v?void 0:v.subtitle)))]}px)`},I);return i.createElement(h,Object.assign({[k]:n,role:b,"aria-selected":l,onClick:x,className:M({active:p||d,selected:l&&"single"===o,activeOnHover:S,radius:a,size:a,dragging:p,clickable:Boolean(x)},(0,D.Y)({px:2},u)),style:B,ref:t},y),L(v)?i.createElement(_,Object.assign({},v,{hasSelectionIcon:"multiple"===o,selected:l,disabled:r})):v)})),U=(0,h.om)("tree-list"),W=({qa:e,id:t,size:n="m",className:s,list:a,multiple:d,containerRef:l,renderItem:r,renderContainer:o=O,onItemClick:u,mapItemDataToContentProps:m})=>{const p=(0,c.u)(),I=null!==t&&void 0!==t?t:p,v=i.useRef(null),b=null!==l&&void 0!==l?l:v,g=i.useMemo((()=>{if(null===u)return;return(e,t)=>{const n={id:e.id,list:a};if(u)null===u||void 0===u||u(n,t);else{w({list:a,multiple:d})(n,t)}}}),[u,a,d]);R({containerRef:b,onItemClick:g,list:a});return o({qa:e,id:`list-${I}`,size:n,containerRef:b,className:U(null,s),list:a,renderItem:(t,s,l)=>{const o=(({qa:e,list:t,onItemClick:n,mapItemDataToContentProps:i,size:s="m",multiple:a=!1,id:d})=>{var l,r;const o=Object.assign(Object.assign(Object.assign({},t.structure.itemsState[d]),t.structure.groupsState[d]),{isLastItem:d===t.structure.visibleFlattenIds[t.structure.visibleFlattenIds.length-1]}),c={id:d,size:s,selected:Boolean(t.state.selectedById[d]),disabled:Boolean(null===(l=t.state.disabledById)||void 0===l?void 0:l[d]),active:d===t.state.activeItemId,onClick:n?e=>n({id:d},e):void 0,selectionViewType:Boolean(a)&&!o.childrenIds?"multiple":"single",content:Object.assign({expanded:null===(r=t.state.expandedById)||void 0===r?void 0:r[d],indentation:o.indentation,isGroup:t.state.expandedById&&d in t.state.expandedById},i(t.structure.itemsById[d]))};return e&&(c.qa=((e,t)=>`${e}-${t}`)(e,d)),{data:t.structure.itemsById[d],props:c,context:o}})({qa:e,id:t,size:n,multiple:d,mapItemDataToContentProps:m,onItemClick:g,list:a});return r?r({id:t,data:o.data,props:o.props,context:o.context,index:s,renderContainerProps:l,list:a}):i.createElement(V,Object.assign({},o.props,l))}})};var H=n(63246),J=n(34379),G=n(46819);const Y=({item:e,groupedId:t,getItemId:n})=>{let i=t;return"function"===typeof n?i=n(B(e)?e.data:e):e&&"object"===typeof e&&"id"in e&&e.id&&(i=e.id),i},K=(e,t)=>t?`${t}-${e}`:`${e}`;function Q({items:e,expandedById:t,getItemId:n}){const s=i.useMemo((()=>function({items:e,getItemId:t,expandedById:n={}}){const i=[],s=(e,a,d,l)=>{const r=K(d,l),o=Y({groupedId:r,item:a,getItemId:t});return l||i.push(o),e.push(o),B(a)&&a.children&&(o in n&&!n[o]||e.push(...a.children.reduce(((e,t,n)=>s(e,t,n,o)),[]))),e},a=e.reduce(((e,t,n)=>s(e,t,n)),[]),d={};for(const[l,r]of a.entries())d[r]=l;return{rootIds:i,visibleFlattenIds:a,idToFlattenIndex:d}}({items:e,expandedById:t,getItemId:n})),[e,t,n]);return s}function X({items:e,defaultExpandedState:t="expanded",getItemId:n}){const i={itemsById:{},groupsState:{},itemsState:{},initialState:{disabledById:{},selectedById:{},expandedById:{}}},s=({item:e,index:a,parentGroupedId:d,parentId:l})=>{const r=K(a,d),o=Y({groupedId:r,item:e,getItemId:n});l&&i.groupsState[l].childrenIds.push(o),i.itemsById[o]=e.data,i.itemsState[o]||(i.itemsState[o]={indentation:0}),"undefined"!==typeof l&&(i.itemsState[o].parentId=l),"undefined"!==typeof e.selected&&(i.initialState.selectedById[o]=e.selected),"undefined"!==typeof e.disabled&&(i.initialState.disabledById[o]=e.disabled),r&&(i.itemsState[o].indentation=(e=>e.split("-"))(r).length-1),e.children&&(i.groupsState[o]={childrenIds:[]},i.initialState.expandedById&&("undefined"===typeof e.expanded?i.initialState.expandedById[o]="expanded"===t:i.initialState.expandedById[o]=e.expanded),e.children.forEach(((e,t)=>{s({item:e,index:t,parentGroupedId:r,parentId:o})})))};return e.forEach(((e,t)=>B(e)?s({item:e,index:t}):(({item:e,index:t})=>{const s=Y({groupedId:String(t),item:e,getItemId:n});i.itemsById[s]=e,i.itemsState[s]||(i.itemsState[s]={indentation:0}),e&&"object"===typeof e&&("selected"in e&&"boolean"===typeof e.selected&&(i.initialState.selectedById[s]=e.selected),"disabled"in e&&"boolean"===typeof e.disabled&&(i.initialState.disabledById[s]=e.disabled))})({item:e,index:t}))),i}const Z=({items:e,getItemId:t,defaultExpandedState:n="expanded",withExpandedState:s=!0,initialState:a,controlledState:d})=>{const{itemsById:l,groupsState:r,itemsState:o,initialState:c}=function({items:e,getItemId:t,defaultExpandedState:n}){const s=i.useRef(t).current;return i.useMemo((()=>X({items:e,getItemId:s,defaultExpandedState:n})),[s,n,e])}({items:e,getItemId:t,defaultExpandedState:n}),u=(({initialState:e,withExpandedState:t})=>{const n=i.useRef(e),s=n.current!==e;n.current=e;const[a,d]=i.useState((()=>{var t;return null!==(t=null===e||void 0===e?void 0:e.disabledById)&&void 0!==t?t:{}})),[l,r]=i.useState((()=>{var t;return null!==(t=null===e||void 0===e?void 0:e.selectedById)&&void 0!==t?t:{}})),[o,c]=i.useState((()=>{var t;return null!==(t=null===e||void 0===e?void 0:e.expandedById)&&void 0!==t?t:{}})),[u,m]=i.useState((()=>null===e||void 0===e?void 0:e.activeItemId));s&&((null===e||void 0===e?void 0:e.disabledById)&&d((t=>Object.assign(Object.assign({},e.disabledById),t))),(null===e||void 0===e?void 0:e.selectedById)&&r((t=>Object.assign(Object.assign({},e.selectedById),t))),(null===e||void 0===e?void 0:e.expandedById)&&c((t=>Object.assign(Object.assign({},e.expandedById),t))),m((t=>null!==t&&void 0!==t?t:null===e||void 0===e?void 0:e.activeItemId)));const p={disabledById:a,selectedById:l,activeItemId:u,setDisabled:d,setSelected:r,setActiveItemId:m};return t&&(p.expandedById=o,p.setExpanded=c),p})({initialState:i.useMemo((()=>({expandedById:Object.assign(Object.assign({},c.expandedById),null===a||void 0===a?void 0:a.expandedById),selectedById:Object.assign(Object.assign({},c.selectedById),null===a||void 0===a?void 0:a.selectedById),disabledById:Object.assign(Object.assign({},c.disabledById),null===a||void 0===a?void 0:a.disabledById),activeItemId:null===a||void 0===a?void 0:a.activeItemId})),[c.disabledById,c.expandedById,c.selectedById,null===a||void 0===a?void 0:a.activeItemId,null===a||void 0===a?void 0:a.disabledById,null===a||void 0===a?void 0:a.expandedById,null===a||void 0===a?void 0:a.selectedById]),withExpandedState:s}),m=i.useMemo((()=>d?Object.assign(Object.assign({},u),d):u),[d,u]),{visibleFlattenIds:p,idToFlattenIndex:I,rootIds:v}=Q({items:e,expandedById:m.expandedById,getItemId:t});return{state:m,structure:{rootIds:v,items:e,visibleFlattenIds:p,idToFlattenIndex:I,itemsById:l,groupsState:r,itemsState:o}}},ee=({defaultValue:e=[],value:t,onUpdate:n})=>{const[s,a]=i.useState(e),d=null!==t&&void 0!==t?t:s,l=!t;return i.useMemo((()=>{const e=d.reduce(((e,t)=>(e[t]=!0,e)),{});return{value:d,selectedById:e,setSelected:t=>{const i=(e=>Object.entries(e).reduce(((e,[t,n])=>(n&&e.push(t),e)),[]))("function"===typeof t?t(e):t);l?a(i):null===n||void 0===n||n(i)},setInnerValue:l?a:void 0}}),[n,l,d])},te=(0,h.om)("tree-select"),ne=e=>i.createElement(V,Object.assign({},e.props,e.renderContainerProps)),ie=i.forwardRef((function({id:e,qa:t,title:n,placement:s,slotBeforeListBody:a,slotAfterListBody:d,size:l="m",defaultOpen:r,width:o,containerRef:u,className:m,containerClassName:f,popupClassName:y,open:h,multiple:x,popupWidth:S,popupDisablePortal:B,items:E,value:C,defaultValue:O,placeholder:j,disabled:k=!1,withExpandedState:N=!0,defaultExpandedState:R="expanded",hasClear:D,errorMessage:F,errorPlacement:P,validationState:T,onClose:$,onOpenChange:A,onUpdate:z,renderControl:M,renderItem:L=ne,renderContainer:q,mapItemDataToContentProps:_,onFocus:V,onBlur:U,getItemId:Y,onItemClick:K},Q){const X=(0,G.I)(),ie=(0,c.u)(),se=null!==e&&void 0!==e?e:ie,ae=`tree-select-popup-${se}`,de=i.useRef(null),le=i.useRef(null),re=i.useRef(null),oe=null!==u&&void 0!==u?u:re,{errorMessage:ce,errorPlacement:ue,validationState:me}=(0,J.Av)({errorMessage:F,errorPlacement:P||"outside",validationState:T}),pe=(0,c.u)(),Ie="invalid"===me,ve=Ie&&Boolean(ce)&&"outside"===ue,be=Ie&&Boolean(ce)&&"inside"===ue,ge=(0,p.N)(Q,le),{toggleOpen:fe,open:ye}=(0,v.F)({defaultOpen:r,onClose:$,onOpenChange:A,open:h}),{value:he,selectedById:xe,setSelected:Se}=ee({value:C,defaultValue:O,onUpdate:z}),Be=Z({controlledState:{selectedById:xe,setSelected:Se},items:E,getItemId:Y,defaultExpandedState:R,withExpandedState:N}),Ee=i.useMemo((()=>{if(null===K)return;return(e,t)=>{const n={id:e.id,list:Be};if(K)null===K||void 0===K||K(n,t);else{w({list:Be,multiple:x})(n,t);const i=Be.state.expandedById&&e.id in Be.state.expandedById;x||i||fe(!1)}}}),[K,Be,x,fe]);i.useLayoutEffect((()=>{var e;return ye&&(null===(e=oe.current)||void 0===e||e.focus({preventScroll:!0})),()=>Be.state.setActiveItemId(void 0)}),[ye]);const Ce=i.useCallback((()=>fe(!1)),[fe]),{focusWithinProps:Oe}=(0,I.R)({onFocusWithin:V,onBlurWithin:i.useCallback((e=>{null===U||void 0===U||U(e),Ce()}),[Ce,U])}),we={list:Be,open:ye,placeholder:j,toggleOpen:fe,clearValue:()=>Be.state.setSelected({}),ref:ge,size:l,value:he,disabled:k,id:se,activeItemId:Be.state.activeItemId,title:n,errorMessage:be?ce:void 0,errorPlacement:ue,validationState:me,hasClear:D,isErrorVisible:Ie},je=M?M(we):i.createElement(b.Y,Object.assign({},we,{selectedOptionsContent:i.Children.toArray(he.map((e=>e in Be.structure.itemsById?_(Be.structure.itemsById[e]).title:""))).join(", "),view:"normal",pin:"round-round",popupId:ae,selectId:se})),ke=Object.assign({},"max"===o&&{width:o}),Ne={};return"number"===typeof o&&(Ne.width=o),i.createElement("div",Object.assign({ref:de},Oe,{className:te(ke,m),style:Ne}),je,i.createElement(g.t,{ref:de,className:te("popup",{size:l},y),controlRef:le,width:S,placement:s,open:ye,handleClose:Ce,disablePortal:B,mobile:X,id:ae},a,i.createElement(W,{list:Be,size:l,className:te("list",f),qa:t,multiple:x,id:`list-${se}`,containerRef:oe,onItemClick:Ee,renderContainer:q,mapItemDataToContentProps:_,renderItem:null!==L&&void 0!==L?L:ne}),d),i.createElement(H.o,{errorMessage:ve?ce:null,errorMessageId:pe}))}));var se=n(28664),ae=n(43781),de=n.n(ae);function le(e,t){return!t||"object"!==typeof t||!("title"in t)||"string"!==typeof t.title||t.title.toLowerCase().includes((e||"").toLowerCase())}function re({items:e,initialFilterValue:t="",filterItem:n,onFilterChange:s,filterItems:a,debounceTimeout:d=300}){const l=i.useRef(null),[r,o]=i.useState(t),[c,u]=i.useState(e),[m,p]=i.useState(e),I=i.useCallback(((e,t)=>{if(a)return()=>a(e,t);if(e){const i=n||le;return()=>function(e,t){const n=(e,i)=>{if(B(i)&&i.children){const s=i.children.reduce(n,[]);s.length?e.push(Object.assign(Object.assign({},i),{data:i.data,children:s})):t(i.data)&&e.push(Object.assign(Object.assign({},i),{data:i.data,children:[]}))}else if(B(i)&&t(i.data)){const{children:t}=i,n=(0,f.Tt)(i,["children"]);e.push(n)}else!B(i)&&t(i)&&e.push(i);return e};return e.reduce(n,[])}(t,(t=>i(e,t)))}return()=>t}),[n,a]);e!==c&&(p(I(r,e)),u(e));const v=i.useCallback(de()((t=>p(I(t,e))),d),[p,I,e,d]),{onFilterUpdate:b,reset:g}=i.useMemo((()=>({reset:()=>{o(t),null===s||void 0===s||s(t),v(t)},onFilterUpdate:e=>{o(e),null===s||void 0===s||s(e),v(e)}})),[v,t,s]);return{filterRef:l,filter:r,reset:g,items:m,onFilterUpdate:b}}var oe=n(72837);const ce=JSON.parse('{"button_apply":"Apply","button_reset":"Reset","button_switcher":"Columns"}'),ue=JSON.parse('{"button_apply":"\u041f\u0440\u0438\u043c\u0435\u043d\u0438\u0442\u044c","button_reset":"\u0421\u0431\u0440\u043e\u0441\u0438\u0442\u044c","button_switcher":"\u041a\u043e\u043b\u043e\u043d\u043a\u0438"}'),me=(0,oe.N)({en:ce,ru:ue},"TableColumnSetupInner"),pe=(0,h.om)("inner-table-column-setup"),Ie=pe("controls"),ve=pe("filter-input"),be=pe("empty-placeholder"),ge={isDragDisabled:!0},fe=e=>({title:e.title}),ye=(e,t)=>"string"!==typeof t.title||t.title.toLowerCase().includes(e.trim().toLowerCase()),he=e=>{const{renderSwitcher:t,popupWidth:n,popupPlacement:p,items:I,onUpdate:v,sortable:b,renderControls:g,className:f,defaultItems:h=I,showResetButton:x,filterable:B,filterPlaceholder:E,filterEmptyMessage:C,filterSettings:O=ye}=e,[w,j]=i.useState(!1),[k,N]=i.useState(b),[R,D]=i.useState(b);b!==R&&(D(b),N(b));const[F,P]=i.useState(I),[T,$]=i.useState(I);I!==T&&($(I),P(I));const A=re({items:F,filterItem:O,debounceTimeout:0}),z=()=>{const e=F.map((({id:e,isSelected:t})=>({id:e,isSelected:t})));v(e),U(!1)},M=()=>i.createElement(a.$,{view:"action",width:"max",onClick:z},me("button_apply")),L="function"===typeof x?x(F):x,q=(({onDragEnd:e,renderControls:t})=>{const n=(0,c.u)();return({renderItem:s,list:a,containerRef:d,id:l,className:r})=>{const{stickyStartItemIdList:c,sortableItemIdList:u,stickyEndItemIdList:m}=((e,t)=>{let n=0;for(;n!==t.length;n++){const i=e[t[n]];if("left"!==(null===i||void 0===i?void 0:i.sticky)&&"start"!==(null===i||void 0===i?void 0:i.sticky))break}let i=t.length;for(;0!==i;i--){const n=e[t[i-1]];if("right"!==(null===n||void 0===n?void 0:n.sticky)&&"end"!==(null===n||void 0===n?void 0:n.sticky))break}return{stickyStartItemIdList:t.slice(0,n),sortableItemIdList:t.slice(n,i),stickyEndItemIdList:t.slice(i)}})(a.structure.itemsById,a.structure.visibleFlattenIds),p=c.map(((e,t)=>s(e,t,ge))),I=u.map(((e,t)=>s(e,t+c.length))),v=m.map(((e,t)=>s(e,p.length+I.length+t,ge)));return i.createElement(i.Fragment,null,i.createElement(S,{ref:d,id:l,className:r},p,i.createElement(o.JY,{onDragEnd:e},i.createElement(o.gL,{droppableId:n,renderClone:(e,t,n)=>{const i={provided:e,snapshot:t};return s(a.structure.visibleFlattenIds[n.source.index],n.source.index,i)}},(e=>i.createElement("div",Object.assign({},e.droppableProps,{ref:e.innerRef}),I,e.placeholder)))),v),i.createElement("div",{className:Ie},t()))}})({onDragEnd:({destination:e,source:t})=>{void 0!==(null===e||void 0===e?void 0:e.index)&&(null===e||void 0===e?void 0:e.index)!==t.index&&P((n=>((e,t,n)=>{const i=[...e],[s]=i.splice(t,1);return i.splice(n,0,s),i})(n,t.index,e.index)))},renderControls:()=>g?g({DefaultApplyButton:M,onApply:z}):i.createElement(y.s,{gapRow:1,direction:"column",className:Ie},L&&i.createElement(a.$,{onClick:()=>{P(h)},width:"max"},me("button_reset")),i.createElement(M,null))}),_=(e=>({data:t,props:n,index:s,renderContainerProps:a})=>{const c=!1===e||!0===(null===a||void 0===a?void 0:a.isDragDisabled),u=c?void 0:i.createElement(d.I,{data:l.A,size:16}),m=t.isRequired?i.createElement(d.I,{data:r}):void 0,p=!t.isRequired&&n.selected,I=Object.assign(Object.assign({},n),{selected:p,selectionViewType:t.isRequired?"single":"multiple",content:Object.assign(Object.assign({},n.content),{startSlot:m,endSlot:u})});if(c)return i.createElement(V,Object.assign({},I,{key:I.id}));const v=(e,t)=>i.createElement(V,Object.assign({},I,e.draggableProps,e.dragHandleProps,{ref:e.innerRef,dragging:t.isDragging}));return(null===a||void 0===a?void 0:a.provided)&&a.snapshot?v(a.provided,a.snapshot):i.createElement(o.sx,{draggableId:n.id,index:s,key:`item-key-${n.id}`,isDragDisabled:c},v)})(k),U=e=>{j(e),!1===e&&(P(I),N(b),A.reset())},W=i.useMemo((()=>(e=>{const t=[];return e.forEach((({id:e,isSelected:n})=>{n&&t.push(e)})),t})(F)),[F]),H=(J=C,()=>i.createElement(m.E,{className:be},J));var J;const G=B?i.createElement(se.k,{size:"m",view:"clear",placeholder:E,value:A.filter,className:ve,onUpdate:e=>{A.onFilterUpdate(e),N(!e.length)},hasClear:!0}):null,Y=A.filter&&!A.items.length?H:q;return i.createElement(ie,{className:pe(null,f),mapItemDataToContentProps:fe,multiple:!0,size:"l",open:w,value:W,items:A.filter?A.items:F,onUpdate:e=>{P((t=>t.map((t=>Object.assign(Object.assign({},t),{isSelected:t.isRequired||e.includes(t.id)})))))},popupWidth:n,onOpenChange:U,placement:p,slotBeforeListBody:G,renderContainer:Y,renderControl:({toggleOpen:e})=>{const n=(0,u.h)(e);return(null===t||void 0===t?void 0:t({onClick:e,onKeyDown:n}))||i.createElement(a.$,{onClick:e,extraProps:{onKeyDown:n}},i.createElement(d.I,{data:s.A}),me("button_switcher"))},renderItem:_})},xe=JSON.parse('{"button_switcher":"Columns"}'),Se=JSON.parse('{"button_switcher":"\u041a\u043e\u043b\u043e\u043d\u043a\u0438"}'),Be=(0,oe.N)({en:xe,ru:Se},"TableColumnSetup"),Ee=(0,h.om)("table-column-setup"),Ce=e=>{const{switcher:t,renderSwitcher:n,disabled:l,popupWidth:r,popupPlacement:o,className:c,items:u,sortable:m=!0,showStatus:p,onUpdate:I}=e,v=u.map((({id:e,title:t,required:n,selected:i,sticky:s})=>({id:e,title:t,isRequired:n,isSelected:i,sticky:s})));return i.createElement(he,{items:v,onUpdate:e=>{I(e.map((({id:e,isSelected:t})=>{const n=u.find((t=>t.id===e));return{id:e,selected:t,title:null===n||void 0===n?void 0:n.title,required:null===n||void 0===n?void 0:n.required}})))},popupPlacement:o,popupWidth:r,renderSwitcher:e=>(null===n||void 0===n?void 0:n(e))||t||i.createElement(a.$,{disabled:l,onClick:e.onClick},i.createElement(d.I,{data:s.A}),Be("button_switcher"),(()=>{if(!p)return null;const e=`${u.reduce(((e,t)=>t.selected?e+1:e),0)}/${u.length}`;return i.createElement("span",{className:Ee("status")},e)})()),sortable:m,className:Ee(null,c)})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/24349.ff3855f6.chunk.js b/ydb/core/viewer/monitoring/static/js/24349.ff3855f6.chunk.js new file mode 100644 index 000000000000..9b30d3fa0166 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/24349.ff3855f6.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[24349],{24349:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-tn",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u062c\u0627\u0646\u0641\u064a_\u0641\u064a\u0641\u0631\u064a_\u0645\u0627\u0631\u0633_\u0623\u0641\u0631\u064a\u0644_\u0645\u0627\u064a_\u062c\u0648\u0627\u0646_\u062c\u0648\u064a\u0644\u064a\u0629_\u0623\u0648\u062a_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),weekStart:1,weekdaysShort:"\u0623\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0623\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u062c\u0627\u0646\u0641\u064a_\u0641\u064a\u0641\u0631\u064a_\u0645\u0627\u0631\u0633_\u0623\u0641\u0631\u064a\u0644_\u0645\u0627\u064a_\u062c\u0648\u0627\u0646_\u062c\u0648\u064a\u0644\u064a\u0629_\u0623\u0648\u062a_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/24458.50eb1325.chunk.js b/ydb/core/viewer/monitoring/static/js/24458.50eb1325.chunk.js new file mode 100644 index 000000000000..f38e7a638112 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/24458.50eb1325.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[24458],{24458:(e,t,r)=>{r.d(t,{default:()=>n});var a=r(31687);const n=r.n(a)()},31687:(e,t,r)=>{var a=r(89343);function n(e){e.register(a),e.languages.hlsl=e.languages.extend("c",{"class-name":[e.languages.c["class-name"],/\b(?:AppendStructuredBuffer|BlendState|Buffer|ByteAddressBuffer|CompileShader|ComputeShader|ConsumeStructuredBuffer|DepthStencilState|DepthStencilView|DomainShader|GeometryShader|Hullshader|InputPatch|LineStream|OutputPatch|PixelShader|PointStream|RWBuffer|RWByteAddressBuffer|RWStructuredBuffer|RWTexture(?:1D|1DArray|2D|2DArray|3D)|RasterizerState|RenderTargetView|SamplerComparisonState|SamplerState|StructuredBuffer|Texture(?:1D|1DArray|2D|2DArray|2DMS|2DMSArray|3D|Cube|CubeArray)|TriangleStream|VertexShader)\b/],keyword:[/\b(?:asm|asm_fragment|auto|break|case|catch|cbuffer|centroid|char|class|column_major|compile|compile_fragment|const|const_cast|continue|default|delete|discard|do|dynamic_cast|else|enum|explicit|export|extern|for|friend|fxgroup|goto|groupshared|if|in|inline|inout|interface|line|lineadj|linear|long|matrix|mutable|namespace|new|nointerpolation|noperspective|operator|out|packoffset|pass|pixelfragment|point|precise|private|protected|public|register|reinterpret_cast|return|row_major|sample|sampler|shared|short|signed|sizeof|snorm|stateblock|stateblock_state|static|static_cast|string|struct|switch|tbuffer|technique|technique10|technique11|template|texture|this|throw|triangle|triangleadj|try|typedef|typename|uniform|union|unorm|unsigned|using|vector|vertexfragment|virtual|void|volatile|while)\b/,/\b(?:bool|double|dword|float|half|int|min(?:10float|12int|16(?:float|int|uint))|uint)(?:[1-4](?:x[1-4])?)?\b/],number:/(?:(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[eE][+-]?\d+)?|\b0x[\da-fA-F]+)[fFhHlLuU]?\b/,boolean:/\b(?:false|true)\b/})}e.exports=n,n.displayName="hlsl",n.aliases=[]},89343:e=>{function t(e){e.languages.c=e.languages.extend("clike",{comment:{pattern:/\/\/(?:[^\r\n\\]|\\(?:\r\n?|\n|(?![\r\n])))*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"class-name":{pattern:/(\b(?:enum|struct)\s+(?:__attribute__\s*\(\([\s\S]*?\)\)\s*)?)\w+|\b[a-z]\w*_t\b/,lookbehind:!0},keyword:/\b(?:_Alignas|_Alignof|_Atomic|_Bool|_Complex|_Generic|_Imaginary|_Noreturn|_Static_assert|_Thread_local|__attribute__|asm|auto|break|case|char|const|continue|default|do|double|else|enum|extern|float|for|goto|if|inline|int|long|register|return|short|signed|sizeof|static|struct|switch|typedef|typeof|union|unsigned|void|volatile|while)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ful]{0,4}/i,operator:/>>=?|<<=?|->|([-+&|:])\1|[?:~]|[-+*/%&|^!=<>]=?/}),e.languages.insertBefore("c","string",{char:{pattern:/'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n]){0,32}'/,greedy:!0}}),e.languages.insertBefore("c","string",{macro:{pattern:/(^[\t ]*)#\s*[a-z](?:[^\r\n\\/]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{string:[{pattern:/^(#\s*include\s*)<[^>]+>/,lookbehind:!0},e.languages.c.string],char:e.languages.c.char,comment:e.languages.c.comment,"macro-name":[{pattern:/(^#\s*define\s+)\w+\b(?!\()/i,lookbehind:!0},{pattern:/(^#\s*define\s+)\w+\b(?=\()/i,lookbehind:!0,alias:"function"}],directive:{pattern:/^(#\s*)[a-z]+/,lookbehind:!0,alias:"keyword"},"directive-hash":/^#/,punctuation:/##|\\(?=[\r\n])/,expression:{pattern:/\S[\s\S]*/,inside:e.languages.c}}}}),e.languages.insertBefore("c","function",{constant:/\b(?:EOF|NULL|SEEK_CUR|SEEK_END|SEEK_SET|__DATE__|__FILE__|__LINE__|__TIMESTAMP__|__TIME__|__func__|stderr|stdin|stdout)\b/}),delete e.languages.c.boolean}e.exports=t,t.displayName="c",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/24534.3cac028e.chunk.js b/ydb/core/viewer/monitoring/static/js/24534.3cac028e.chunk.js new file mode 100644 index 000000000000..ab502d603e80 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/24534.3cac028e.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 24534.3cac028e.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[24534],{24534:(e,i,t)=>{t.r(i),t.d(i,{conf:()=>n,language:()=>s});var n={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},s={defaultToken:"",tokenPostfix:".cypher",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ALL","AND","AS","ASC","ASCENDING","BY","CALL","CASE","CONTAINS","CREATE","DELETE","DESC","DESCENDING","DETACH","DISTINCT","ELSE","END","ENDS","EXISTS","IN","IS","LIMIT","MANDATORY","MATCH","MERGE","NOT","ON","ON","OPTIONAL","OR","ORDER","REMOVE","RETURN","SET","SKIP","STARTS","THEN","UNION","UNWIND","WHEN","WHERE","WITH","XOR","YIELD"],builtinLiterals:["true","TRUE","false","FALSE","null","NULL"],builtinFunctions:["abs","acos","asin","atan","atan2","avg","ceil","coalesce","collect","cos","cot","count","degrees","e","endNode","exists","exp","floor","head","id","keys","labels","last","left","length","log","log10","lTrim","max","min","nodes","percentileCont","percentileDisc","pi","properties","radians","rand","range","relationships","replace","reverse","right","round","rTrim","sign","sin","size","split","sqrt","startNode","stDev","stDevP","substring","sum","tail","tan","timestamp","toBoolean","toFloat","toInteger","toLower","toString","toUpper","trim","type"],operators:["+","-","*","/","%","^","=","<>","<",">","<=",">=","->","<-","--\x3e","<--"],escapes:/\\(?:[tbnrf\\"'`]|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,digits:/\d+/,octaldigits:/[0-7]+/,hexdigits:/[0-9a-fA-F]+/,tokenizer:{root:[[/[{}[\]()]/,"@brackets"],{include:"common"}],common:[{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},[/:[a-zA-Z_][\w]*/,"type.identifier"],[/[a-zA-Z_][\w]*(?=\()/,{cases:{"@builtinFunctions":"predefined.function"}}],[/[a-zA-Z_$][\w$]*/,{cases:{"@keywords":"keyword","@builtinLiterals":"predefined.literal","@default":"identifier"}}],[/`/,"identifier.escape","@identifierBacktick"],[/[;,.:|]/,"delimiter"],[/[<>=%+\-*/^]+/,{cases:{"@operators":"delimiter","@default":""}}]],numbers:[[/-?(@digits)[eE](-?(@digits))?/,"number.float"],[/-?(@digits)?\.(@digits)([eE]-?(@digits))?/,"number.float"],[/-?0x(@hexdigits)/,"number.hex"],[/-?0(@octaldigits)/,"number.octal"],[/-?(@digits)/,"number"]],strings:[[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/"/,"string","@stringDouble"],[/'/,"string","@stringSingle"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/\/\/.*/,"comment"],[/[^/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[/*]/,"comment"]],stringDouble:[[/[^\\"]+/,"string"],[/@escapes/,"string"],[/\\./,"string.invalid"],[/"/,"string","@pop"]],stringSingle:[[/[^\\']+/,"string"],[/@escapes/,"string"],[/\\./,"string.invalid"],[/'/,"string","@pop"]],identifierBacktick:[[/[^\\`]+/,"identifier.escape"],[/@escapes/,"identifier.escape"],[/\\./,"identifier.escape.invalid"],[/`/,"identifier.escape","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2372.880a31f6.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/24534.3cac028e.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2372.880a31f6.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/24534.3cac028e.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/246.13bb9db2.chunk.js b/ydb/core/viewer/monitoring/static/js/246.13bb9db2.chunk.js deleted file mode 100644 index 1e02b6bb88c5..000000000000 --- a/ydb/core/viewer/monitoring/static/js/246.13bb9db2.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 246.13bb9db2.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[246],{10246:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>o,language:()=>s});var o={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},s={tokenPostfix:".tcl",specialFunctions:["set","unset","rename","variable","proc","coroutine","foreach","incr","append","lappend","linsert","lreplace"],mainFunctions:["if","then","elseif","else","case","switch","while","for","break","continue","return","package","namespace","catch","exit","eval","expr","uplevel","upvar"],builtinFunctions:["file","info","concat","join","lindex","list","llength","lrange","lsearch","lsort","split","array","parray","binary","format","regexp","regsub","scan","string","subst","dict","cd","clock","exec","glob","pid","pwd","close","eof","fblocked","fconfigure","fcopy","fileevent","flush","gets","open","puts","read","seek","socket","tell","interp","after","auto_execok","auto_load","auto_mkindex","auto_reset","bgerror","error","global","history","load","source","time","trace","unknown","unset","update","vwait","winfo","wm","bind","event","pack","place","grid","font","bell","clipboard","destroy","focus","grab","lower","option","raise","selection","send","tk","tkwait","tk_bisque","tk_focusNext","tk_focusPrev","tk_focusFollowsMouse","tk_popup","tk_setPalette"],symbols:/[=>{e.r(S),e.d(S,{conf:()=>T,language:()=>R});var T={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},R={defaultToken:"",tokenPostfix:".redis",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["APPEND","AUTH","BGREWRITEAOF","BGSAVE","BITCOUNT","BITFIELD","BITOP","BITPOS","BLPOP","BRPOP","BRPOPLPUSH","CLIENT","KILL","LIST","GETNAME","PAUSE","REPLY","SETNAME","CLUSTER","ADDSLOTS","COUNT-FAILURE-REPORTS","COUNTKEYSINSLOT","DELSLOTS","FAILOVER","FORGET","GETKEYSINSLOT","INFO","KEYSLOT","MEET","NODES","REPLICATE","RESET","SAVECONFIG","SET-CONFIG-EPOCH","SETSLOT","SLAVES","SLOTS","COMMAND","COUNT","GETKEYS","CONFIG","GET","REWRITE","SET","RESETSTAT","DBSIZE","DEBUG","OBJECT","SEGFAULT","DECR","DECRBY","DEL","DISCARD","DUMP","ECHO","EVAL","EVALSHA","EXEC","EXISTS","EXPIRE","EXPIREAT","FLUSHALL","FLUSHDB","GEOADD","GEOHASH","GEOPOS","GEODIST","GEORADIUS","GEORADIUSBYMEMBER","GETBIT","GETRANGE","GETSET","HDEL","HEXISTS","HGET","HGETALL","HINCRBY","HINCRBYFLOAT","HKEYS","HLEN","HMGET","HMSET","HSET","HSETNX","HSTRLEN","HVALS","INCR","INCRBY","INCRBYFLOAT","KEYS","LASTSAVE","LINDEX","LINSERT","LLEN","LPOP","LPUSH","LPUSHX","LRANGE","LREM","LSET","LTRIM","MGET","MIGRATE","MONITOR","MOVE","MSET","MSETNX","MULTI","PERSIST","PEXPIRE","PEXPIREAT","PFADD","PFCOUNT","PFMERGE","PING","PSETEX","PSUBSCRIBE","PUBSUB","PTTL","PUBLISH","PUNSUBSCRIBE","QUIT","RANDOMKEY","READONLY","READWRITE","RENAME","RENAMENX","RESTORE","ROLE","RPOP","RPOPLPUSH","RPUSH","RPUSHX","SADD","SAVE","SCARD","SCRIPT","FLUSH","LOAD","SDIFF","SDIFFSTORE","SELECT","SETBIT","SETEX","SETNX","SETRANGE","SHUTDOWN","SINTER","SINTERSTORE","SISMEMBER","SLAVEOF","SLOWLOG","SMEMBERS","SMOVE","SORT","SPOP","SRANDMEMBER","SREM","STRLEN","SUBSCRIBE","SUNION","SUNIONSTORE","SWAPDB","SYNC","TIME","TOUCH","TTL","TYPE","UNSUBSCRIBE","UNLINK","UNWATCH","WAIT","WATCH","ZADD","ZCARD","ZCOUNT","ZINCRBY","ZINTERSTORE","ZLEXCOUNT","ZRANGE","ZRANGEBYLEX","ZREVRANGEBYLEX","ZRANGEBYSCORE","ZRANK","ZREM","ZREMRANGEBYLEX","ZREMRANGEBYRANK","ZREMRANGEBYSCORE","ZREVRANGE","ZREVRANGEBYSCORE","ZREVRANK","ZSCORE","ZUNIONSTORE","SCAN","SSCAN","HSCAN","ZSCAN"],operators:[],builtinFunctions:[],builtinVariables:[],pseudoColumns:[],tokenizer:{root:[{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@keywords":"keyword","@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}],[/"/,{token:"string.double",next:"@stringDouble"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],stringDouble:[[/[^"]+/,"string.double"],[/""/,"string.double"],[/"/,{token:"string.double",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/246.13bb9db2.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/24662.5e8417ae.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/246.13bb9db2.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/24662.5e8417ae.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/25007.2ae44a13.chunk.js b/ydb/core/viewer/monitoring/static/js/25007.2ae44a13.chunk.js new file mode 100644 index 000000000000..37aad67ba9b9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/25007.2ae44a13.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[25007],{19678:e=>{function t(e){e.languages.autoit={comment:[/;.*/,{pattern:/(^[\t ]*)#(?:comments-start|cs)[\s\S]*?^[ \t]*#(?:ce|comments-end)/m,lookbehind:!0}],url:{pattern:/(^[\t ]*#include\s+)(?:<[^\r\n>]+>|"[^\r\n"]+")/m,lookbehind:!0},string:{pattern:/(["'])(?:\1\1|(?!\1)[^\r\n])*\1/,greedy:!0,inside:{variable:/([%$@])\w+\1/}},directive:{pattern:/(^[\t ]*)#[\w-]+/m,lookbehind:!0,alias:"keyword"},function:/\b\w+(?=\()/,variable:/[$@]\w+/,keyword:/\b(?:Case|Const|Continue(?:Case|Loop)|Default|Dim|Do|Else(?:If)?|End(?:Func|If|Select|Switch|With)|Enum|Exit(?:Loop)?|For|Func|Global|If|In|Local|Next|Null|ReDim|Select|Static|Step|Switch|Then|To|Until|Volatile|WEnd|While|With)\b/i,number:/\b(?:0x[\da-f]+|\d+(?:\.\d+)?(?:e[+-]?\d+)?)\b/i,boolean:/\b(?:False|True)\b/i,operator:/<[=>]?|[-+*\/=&>]=?|[?^]|\b(?:And|Not|Or)\b/i,punctuation:/[\[\]().,:]/}}e.exports=t,t.displayName="autoit",t.aliases=[]},25007:(e,t,n)=>{n.d(t,{default:()=>a});var i=n(19678);const a=n.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/25101.06af1360.chunk.js b/ydb/core/viewer/monitoring/static/js/25101.06af1360.chunk.js new file mode 100644 index 000000000000..4bd0c7dbcc35 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/25101.06af1360.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[25101],{11348:E=>{function T(E){E.languages.n1ql={comment:{pattern:/\/\*[\s\S]*?(?:$|\*\/)|--.*/,greedy:!0},string:{pattern:/(["'])(?:\\[\s\S]|(?!\1)[^\\]|\1\1)*\1/,greedy:!0},identifier:{pattern:/`(?:\\[\s\S]|[^\\`]|``)*`/,greedy:!0},parameter:/\$[\w.]+/,keyword:/\b(?:ADVISE|ALL|ALTER|ANALYZE|AS|ASC|AT|BEGIN|BINARY|BOOLEAN|BREAK|BUCKET|BUILD|BY|CALL|CAST|CLUSTER|COLLATE|COLLECTION|COMMIT|COMMITTED|CONNECT|CONTINUE|CORRELATE|CORRELATED|COVER|CREATE|CURRENT|DATABASE|DATASET|DATASTORE|DECLARE|DECREMENT|DELETE|DERIVED|DESC|DESCRIBE|DISTINCT|DO|DROP|EACH|ELEMENT|EXCEPT|EXCLUDE|EXECUTE|EXPLAIN|FETCH|FILTER|FLATTEN|FLUSH|FOLLOWING|FOR|FORCE|FROM|FTS|FUNCTION|GOLANG|GRANT|GROUP|GROUPS|GSI|HASH|HAVING|IF|IGNORE|ILIKE|INCLUDE|INCREMENT|INDEX|INFER|INLINE|INNER|INSERT|INTERSECT|INTO|IS|ISOLATION|JAVASCRIPT|JOIN|KEY|KEYS|KEYSPACE|KNOWN|LANGUAGE|LAST|LEFT|LET|LETTING|LEVEL|LIMIT|LSM|MAP|MAPPING|MATCHED|MATERIALIZED|MERGE|MINUS|MISSING|NAMESPACE|NEST|NL|NO|NTH_VALUE|NULL|NULLS|NUMBER|OBJECT|OFFSET|ON|OPTION|OPTIONS|ORDER|OTHERS|OUTER|OVER|PARSE|PARTITION|PASSWORD|PATH|POOL|PRECEDING|PREPARE|PRIMARY|PRIVATE|PRIVILEGE|PROBE|PROCEDURE|PUBLIC|RANGE|RAW|REALM|REDUCE|RENAME|RESPECT|RETURN|RETURNING|REVOKE|RIGHT|ROLE|ROLLBACK|ROW|ROWS|SATISFIES|SAVEPOINT|SCHEMA|SCOPE|SELECT|SELF|SEMI|SET|SHOW|SOME|START|STATISTICS|STRING|SYSTEM|TIES|TO|TRAN|TRANSACTION|TRIGGER|TRUNCATE|UNBOUNDED|UNDER|UNION|UNIQUE|UNKNOWN|UNNEST|UNSET|UPDATE|UPSERT|USE|USER|USING|VALIDATE|VALUE|VALUES|VIA|VIEW|WHERE|WHILE|WINDOW|WITH|WORK|XOR)\b/i,function:/\b[a-z_]\w*(?=\s*\()/i,boolean:/\b(?:FALSE|TRUE)\b/i,number:/(?:\b\d+\.|\B\.)\d+e[+\-]?\d+\b|\b\d+(?:\.\d*)?|\B\.\d+\b/i,operator:/[-+*\/%]|!=|==?|\|\||<[>=]?|>=?|\b(?:AND|ANY|ARRAY|BETWEEN|CASE|ELSE|END|EVERY|EXISTS|FIRST|IN|LIKE|NOT|OR|THEN|VALUED|WHEN|WITHIN)\b/i,punctuation:/[;[\](),.{}:]/}}E.exports=T,T.displayName="n1ql",T.aliases=[]},25101:(E,T,N)=>{N.d(T,{default:()=>I});var R=N(11348);const I=N.n(R)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2512.732a0e0c.chunk.js b/ydb/core/viewer/monitoring/static/js/2512.732a0e0c.chunk.js deleted file mode 100644 index 941902700463..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2512.732a0e0c.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2512],{42655:(e,s,n)=>{n.d(s,{y:()=>c});var t=n(59284),l=n(89169),r=n(77506),a=n(66781),o=n(60712);const i=(0,r.cn)("ydb-info-viewer-skeleton"),d=()=>(0,o.jsxs)("div",{className:i("label"),children:[(0,o.jsx)(l.E,{className:i("label__text")}),(0,o.jsx)("div",{className:i("label__dots")})]}),c=({rows:e=8,className:s,delay:n=600})=>{const[r]=(0,a.y)(n);let c=(0,o.jsxs)(t.Fragment,{children:[(0,o.jsx)(d,{}),(0,o.jsx)(l.E,{className:i("value")})]});return r||(c=null),(0,o.jsx)("div",{className:i(null,s),children:[...new Array(e)].map(((e,s)=>(0,o.jsx)("div",{className:i("row"),children:c},`skeleton-row-${s}`)))})}},70043:(e,s,n)=>{n.d(s,{E:()=>a});var t=n(89169),l=n(66781),r=n(60712);const a=({delay:e=600,className:s})=>{const[n]=(0,l.y)(e);return n?(0,r.jsx)(t.E,{className:s}):null}},59984:(e,s,n)=>{n.d(s,{Y:()=>i});n(59284);var t=n(87184),l=n(77506),r=n(60712);const a=(0,l.cn)("tag"),o=({text:e,type:s})=>(0,r.jsx)("div",{className:a({type:s}),children:e}),i=({tags:e,tagsType:s,className:n="",gap:l=1})=>(0,r.jsx)(t.s,{className:n,gap:l,wrap:"wrap",alignItems:"center",children:e&&e.map(((e,n)=>(0,r.jsx)(o,{text:e,type:s},n)))})},6488:(e,s,n)=>{n.r(s),n.d(s,{Cluster:()=>Vs});var t=n(59284),l=n(89169),r=n(23871),a=n(61750),o=n(10755),i=n(67087),d=n(90053),c=n(10508),u=n(44294),v=n(92459),h=n(67028),p=n(67157),m=n(40174),g=n(77506),j=n(90182),x=n(66592),N=n(7117),f=n(99936),b=n(88616),y=n(4557),C=n(84476),k=n(28539),w=n(44508),T=n(78524),_=n(48295),S=n(9252),V=n(17594),E=n(95963),O=n(89073),L=n(40336),M=n(63291),D=n(54309),z=n(78668),A=n(71661),G=n(25196),I=n(48372);const P=JSON.parse('{"field_links":"Links","field_monitoring-link":"Monitoring","context_unknown":"unknown database"}'),R=(0,I.g4)("ydb-tenant-name-wrapper",{en:P});var $=n(60712);function B({tenant:e,additionalTenantsProps:s}){var n;const t=(0,j.N4)(z._5),l=((e,s)=>{var n,t;if("function"!==typeof(null===s||void 0===s?void 0:s.prepareTenantBackend))return;let l=null!==(n=e.MonitoringEndpoint)&&void 0!==n?n:e.backend;const r=null!==(t=e.NodeIds)&&void 0!==t?t:e.sharedNodeIds;!l&&r&&r.length>0&&(l={NodeId:r[Math.floor(Math.random()*r.length)]});return s.prepareTenantBackend(l)})(e,s),r=Boolean(l),a=null===s||void 0===s||null===(n=s.getMonitoringLink)||void 0===n?void 0:n.call(s,e.Name,e.Type);return(0,$.jsx)(A.s,{disabled:!t||!a,delayClosing:200,content:a?(0,$.jsx)(L.u,{responsive:!0,children:(0,$.jsx)(L.u.Item,{name:R("field_links"),children:(0,$.jsx)(G.K,{title:R("field_monitoring-link"),url:a})})}):null,placement:["top","bottom"],behavior:M.m.Immediate,children:(0,$.jsx)(c.c,{externalLink:r,name:e.Name||R("context_unknown"),withLeftTrim:!0,status:e.Overall,hasClipboardButton:!0,path:(0,D.YL)({database:e.Name,backend:l})})})}var F=n(58351),U=n(88610),Y=n(53850),Z=n(23536),W=n.n(Z),q=n(54090),Q=n(76086),H=n(56674);const J=(0,Y.Mz)((e=>e),(e=>H.GJ.endpoints.getTenantsInfo.select({clusterName:e}))),K=(0,Y.Mz)((e=>e),((e,s)=>J(s)),(e=>(0,U.CN)(e,Q.Xm)),((e,s,n)=>{var t;const l=null!==(t=s(e).data)&&void 0!==t?t:[];return!n&&l.length>1?l.filter((e=>"Domain"!==e.Type)):l})),X=e=>e.tenants.searchValue,ee=(0,Y.Mz)([K,U.yV,X],((e,s,n)=>{let t=((e,s)=>s===U.s$.ALL?e:e.filter((e=>e.Overall&&e.Overall!==q.m.Green)))(e,s);return t=((e,s)=>e.filter((e=>{const n=new RegExp(W()(s),"i");return n.test(e.Name||"")||n.test(e.controlPlaneName)})))(t,n),t}));var se=n(56839);const ne=(0,g.cn)("tenants"),te=({additionalTenantsProps:e})=>{const s=(0,j.YQ)(),[n]=(0,j.Nt)(),{currentData:l,isFetching:r,error:a}=H.GJ.useGetTenantsInfoQuery({clusterName:F.SL},{pollingInterval:n}),o=r&&void 0===l,i=(0,j.N4)((e=>K(e,F.SL))),d=(0,j.N4)(X),c=(0,j.N4)((e=>ee(e,F.SL))),u=(0,j.N4)(U.yV),v=e=>{s((0,U.$u)(e))},h=e=>{s((0,H.gB)(e))};return(0,$.jsxs)(O.L,{children:[(0,$.jsx)(O.L.Controls,{children:(0,$.jsxs)(t.Fragment,{children:[(0,$.jsx)(E.v,{value:d,onChange:h,placeholder:"Database name",className:ne("search")}),(0,$.jsx)(S.k,{value:u,onChange:v}),(0,$.jsx)(k.T,{total:i.length,current:(null===c||void 0===c?void 0:c.length)||0,label:"Databases",loading:o})]})}),a?(0,$.jsx)(w.o,{error:a}):null,(0,$.jsx)(O.L.Table,{loading:o,children:l?(()=>{const s=[{name:"Name",header:"Database",render:({row:s})=>(0,$.jsx)(B,{tenant:s,additionalTenantsProps:e}),width:440,sortable:!0,defaultOrder:y.Ay.DESCENDING},{name:"controlPlaneName",header:"Name",render:({row:e})=>e.controlPlaneName,width:200,sortable:!0,defaultOrder:y.Ay.DESCENDING},{name:"Type",width:200,resizeMinWidth:150,render:({row:e})=>"Serverless"!==e.Type?e.Type:(0,$.jsxs)("div",{className:ne("type"),children:[(0,$.jsx)("span",{className:ne("type-value"),children:e.Type}),(0,$.jsx)(C.$,{className:ne("type-button"),onClick:()=>h(e.sharedTenantName||""),children:"Show shared"})]})},{name:"State",width:90,render:({row:e})=>e.State?e.State.toLowerCase():"\u2014",customStyle:()=>({textTransform:"capitalize"})},{name:"cpu",header:"CPU",width:80,render:({row:e})=>e.cpu&&e.cpu>1e4?(0,se.iM)(e.cpu):"\u2014",align:y.Ay.RIGHT,defaultOrder:y.Ay.DESCENDING},{name:"memory",header:"Memory",width:120,render:({row:e})=>e.memory?(0,se.vX)(e.memory):"\u2014",align:y.Ay.RIGHT,defaultOrder:y.Ay.DESCENDING},{name:"storage",header:"Storage",width:120,render:({row:e})=>e.storage?(0,se.vX)(e.storage):"\u2014",align:y.Ay.RIGHT,defaultOrder:y.Ay.DESCENDING},{name:"nodesCount",header:"Nodes",width:100,render:({row:e})=>e.nodesCount?(0,se.ZV)(e.nodesCount):"\u2014",align:y.Ay.RIGHT,defaultOrder:y.Ay.DESCENDING},{name:"groupsCount",header:"Groups",width:100,render:({row:e})=>e.groupsCount?(0,se.ZV)(e.groupsCount):"\u2014",align:y.Ay.RIGHT,defaultOrder:y.Ay.DESCENDING},{name:"PoolStats",header:"Pools",width:100,resizeMinWidth:60,sortAccessor:({PoolStats:e=[]})=>e.reduce(((e,s)=>e+(s.Usage||0)),0),defaultOrder:y.Ay.DESCENDING,align:y.Ay.LEFT,render:({row:e})=>(0,$.jsx)(_._,{pools:e.PoolStats})}];return 0===c.length&&u!==U.s$.ALL?(0,$.jsx)(T.v,{name:"thumbsUp",width:"200"}):(0,$.jsx)(V.l,{columnsWidthLSKey:"databasesTableColumnsWidth",data:c,columns:s,settings:Q.N3,emptyDataMessage:"No such tenants"})})():null})]})};var le=n(44433),re=n(74321),ae=n(52248),oe=n(15298),ie=n(18143);const de=(0,g.cn)("ydb-cluster-versions-bar"),ce=({versionsValues:e=[],size:s="s",progressClassName:n})=>(0,$.jsxs)("div",{className:de(),children:[(0,$.jsx)(ie.k,{value:100,stack:e,size:s,className:n}),(0,$.jsx)("div",{className:de("versions"),children:e.map(((s,n)=>(0,$.jsx)("div",{className:de("version-title"),style:{color:s.color},title:s.version,children:`${s.version}${n===e.length-1?"":","}`},s.version)))})]});var ue=n(63126),ve=n(78762),he=n(71294);function pe(e){return[(0,ve._E)(),(0,ve.Nh)(e),(0,ve.jl)(),(0,ve.pH)(),(0,ve.fr)(),(0,ve.ID)()]}const me=({nodes:e})=>{const{balancer:s}=(0,p.Zd)(),{additionalNodesProps:n}=(0,he.B)({balancer:s}),t=pe({getNodeRef:n.getNodeRef});return(0,$.jsx)(V.l,{columnsWidthLSKey:"versionsTableColumnsWidth",data:e,columns:t,settings:Q.N3})};var ge=n(96873);const je=(0,g.cn)("ydb-versions-nodes-tree-title"),xe=({title:e,nodes:s,items:n,versionColor:t,versionsValues:l})=>{let r;return r=n?n.reduce(((e,s)=>s.nodes?e+s.nodes.length:e),0):s?s.length:0,(0,$.jsxs)("div",{className:je("overview"),children:[(0,$.jsxs)("div",{className:je("overview-container"),children:[t?(0,$.jsx)("div",{className:je("version-color"),style:{background:t}}):null,e?(0,$.jsxs)("span",{className:je("overview-title"),children:[e,(0,$.jsx)(ge.b,{text:e,size:"s",className:je("clipboard-button"),view:"normal"})]}):null]}),(0,$.jsxs)("div",{className:je("overview-info"),children:[(0,$.jsxs)("div",{children:[(0,$.jsx)("span",{className:je("info-value"),children:r}),(0,$.jsx)("span",{className:je("info-label",{margin:"left"}),children:"Nodes"})]}),l?(0,$.jsxs)("div",{className:je("version-progress"),children:[(0,$.jsx)("span",{className:je("info-label",{margin:"right"}),children:"Versions"}),(0,$.jsx)(ie.k,{size:"s",value:100,stack:l})]}):null]})]})},Ne=(0,g.cn)("ydb-versions-grouped-node-tree"),fe=({title:e,nodes:s,items:n,expanded:l=!1,versionColor:r,versionsValues:a,level:o=0})=>{const[i,d]=t.useState(!1);t.useEffect((()=>{d(l)}),[l]);const c=(0,$.jsx)(xe,{title:e,nodes:s,items:n,versionColor:r,versionsValues:a}),u=()=>{d((e=>!e))};return n?(0,$.jsx)("div",{className:Ne({"first-level":0===o}),children:(0,$.jsx)(ue.G,{name:c,collapsed:!i,hasArrow:!0,onClick:u,onArrowClick:u,children:n.map(((e,s)=>(0,$.jsx)(fe,{title:e.title,nodes:e.nodes,expanded:l,versionColor:e.versionColor,level:o+1},s)))},e)}):(0,$.jsx)("div",{className:Ne({"first-level":0===o}),children:(0,$.jsx)(ue.G,{name:c,collapsed:!i,hasArrow:!0,onClick:u,onArrowClick:u,children:(0,$.jsx)("div",{className:Ne("dt-wrapper"),children:(0,$.jsx)(me,{nodes:s||[]})})},e)})};var be=n(78018),ye=n.n(be),Ce=n(38596);const ke=.5,we=(e=[],s)=>{const n=e.reduce(((e,s)=>(s.Version&&(e[s.Version]?e[s.Version]=e[s.Version]+1:e[s.Version]=1),e)),{});return _e(Object.keys(n).map((t=>{const l=n[t]/e.length*100;return{title:t,version:t,color:null===s||void 0===s?void 0:s.get((0,Ce.U)(t)),value:le+s.count),0);return _e(e.map((e=>{const n=e.count/t*100;return{title:e.name,version:e.name,color:null===s||void 0===s?void 0:s.get(e.name),value:n{t+=e.value,e.value>s&&(s=e.value,n=l)}));const l=[...e];return l[n]={...e[n],value:s+100-t},l}let Se=function(e){return e.VERSION="Version",e.TENANT="Database",e.STORAGE="Storage",e}({});const Ve=(e,s)=>{var n;return(null===(n=e.title)||void 0===n?void 0:n.localeCompare(s.title||""))||-1},Ee=JSON.parse('{"title_overall":"Overall","title_storage":"Storage nodes","title_database":"Database nodes","title_other":"Other nodes"}'),Oe=(0,I.g4)("ydb-versions",{en:Ee});var Le=n(44992),Me=n(98730);const De=(0,g.cn)("ydb-versions"),ze=({versionToColor:e,cluster:s})=>{const[n]=(0,j.Nt)(),l=((e,s)=>{const{currentData:n}=oe.s.useGetNodesQuery((0,Me.L)(e)?Le.hT:{tablets:!1,fieldsRequired:["SystemState"],group:"Version"});return t.useMemo((()=>(0,Me.L)(e)&&e.MapVersions?Te(Object.entries(e.MapVersions).map((([e,s])=>({name:e,count:s}))),s,e.NodesTotal):n?Array.isArray(n.NodeGroups)?Te(n.NodeGroups,s,null===e||void 0===e?void 0:e.NodesTotal):we(n.Nodes,s):[]),[n,s,e])})(s,e),{currentData:r,isLoading:a}=oe.s.useGetNodesQuery({tablets:!1,fieldsRequired:["SystemState"]},{pollingInterval:n}),o=null===r||void 0===r?void 0:r.Nodes,[i,d]=t.useState(Se.VERSION),[c,u]=t.useState(!1),v=e=>{d(e)};if(a)return(0,$.jsx)(ae.a,{});const h=((e,s,n)=>{if(e&&e.length){if(n===Se.VERSION){const n=ye()(e,"Version");return Object.keys(n).map((e=>{const t=n[e].filter((({Tenants:e})=>Boolean(e))),l=ye()(t,"Tenants"),r=Object.keys(l).map((e=>({title:e,nodes:l[e]}))).sort(Ve);return r.length?{title:e,items:r,versionColor:null===s||void 0===s?void 0:s.get((0,Ce.U)(e))}:null})).filter((e=>Boolean(e)))}{const n=e.filter((({Tenants:e})=>Boolean(e))),t=ye()(n,"Tenants");return Object.keys(t).map((e=>{const n=we(t[e],s),l=ye()(t[e],"Version"),r=Object.keys(l).map((e=>({title:e,nodes:l[e],versionColor:null===s||void 0===s?void 0:s.get((0,Ce.U)(e))})));return r.length?{title:e,items:r,versionsValues:n}:null})).filter((e=>Boolean(e))).sort(Ve)}}})(o,e,i),p=((e,s)=>{if(!e||!e.length)return;const n=e.filter((({Roles:e})=>null===e||void 0===e?void 0:e.includes("Storage"))),t=ye()(n,"Version");return Object.keys(t).map((e=>({title:e,nodes:t[e],versionColor:null===s||void 0===s?void 0:s.get((0,Ce.U)(e))})))})(o,e),m=((e,s)=>{if(!e||!e.length)return;const n=e.filter((({Roles:e,Version:s})=>!e&&s)),t=ye()(n,"Version");return Object.keys(t).map((e=>({title:e,nodes:t[e],versionColor:null===s||void 0===s?void 0:s.get((0,Ce.U)(e))})))})(o,e),g=null!==p&&void 0!==p&&p.length?(0,$.jsxs)(t.Fragment,{children:[(0,$.jsx)("h4",{children:Oe("title_storage")}),p.map((({title:e,nodes:s,items:n,versionColor:t})=>(0,$.jsx)(fe,{title:e,nodes:s,items:n,versionColor:t},`storage-nodes-${e}`)))]}):null,x=null!==h&&void 0!==h&&h.length?(0,$.jsxs)(t.Fragment,{children:[(0,$.jsx)("h4",{children:Oe("title_database")}),(0,$.jsxs)("div",{className:De("controls"),children:[(0,$.jsxs)("div",{className:De("group"),children:[(0,$.jsx)("span",{className:De("label"),children:"Group by:"}),(0,$.jsxs)(le.a,{value:i,onUpdate:v,children:[(0,$.jsx)(le.a.Option,{value:Se.TENANT,children:Se.TENANT}),(0,$.jsx)(le.a.Option,{value:Se.VERSION,children:Se.VERSION})]})]}),(0,$.jsx)(re.S,{className:De("checkbox"),onChange:()=>u((e=>!e)),checked:c,children:"All expanded"})]}),h.map((({title:e,nodes:s,items:n,versionColor:t,versionsValues:l})=>(0,$.jsx)(fe,{title:e,nodes:s,items:n,expanded:c,versionColor:t,versionsValues:l},`tenant-nodes-${e}`)))]}):null,N=null!==m&&void 0!==m&&m.length?(0,$.jsxs)(t.Fragment,{children:[(0,$.jsx)("h4",{children:Oe("title_other")}),m.map((({title:e,nodes:s,items:n,versionColor:t,versionsValues:l})=>(0,$.jsx)(fe,{title:e,nodes:s,items:n,versionColor:t,versionsValues:l},`other-nodes-${e}`)))]}):null,f=(0,$.jsxs)(t.Fragment,{children:[(0,$.jsx)("h4",{children:Oe("title_overall")}),(0,$.jsx)("div",{className:De("overall-wrapper"),children:(0,$.jsx)(ce,{progressClassName:De("overall-progress"),versionsValues:l.filter((e=>"unknown"!==e.title)),size:"m"})})]});return(0,$.jsxs)("div",{className:De(),children:[f,g,x,N]})};var Ae=n(98089),Ge=n(87184),Ie=n(59984),Pe=n(7435);const Re=JSON.parse('{"disk-type":"Disk Type","erasure":"Erasure","allocated":"Allocated","available":"Available","usage":"Usage","label_nodes-state":"Nodes state","label_dc":"Nodes data centers","storage-size":"Storage size","storage-groups":"Storage groups, {{diskType}}","links":"Links","link_cores":"Coredumps","link_logging":"Logging","link_slo-logs":"Slo Logs","context_cores":"cores","title_cpu":"CPU","title_storage":"Storage","title_memory":"Memory","title_info":"Info","title_links":"Links","label_nodes":"Nodes","label_hosts":"Hosts","label_storage-groups":"Storage groups","label_databases":"Databases","label_load":"Load"}'),$e=(0,I.g4)("ydb-cluster",{en:Re});var Be=n(2102);const Fe=(0,g.cn)("ydb-doughnut-metrics");function Ue({status:e,fillWidth:s,children:n,className:t}){let l="var(--g-color-line-generic-solid)",r=3.6*s-90;s>50&&(l="var(--doughnut-color)",r=3.6*s+90);const a=r;return(0,$.jsx)("div",{className:Fe(null,t),children:(0,$.jsx)("div",{style:{backgroundImage:`linear-gradient(${a}deg, transparent 50%, ${l} 50%), linear-gradient(-90deg, var(--g-color-line-generic-solid) 50%, transparent 50%)`},className:Fe("doughnut",{status:e}),children:(0,$.jsx)("div",{className:Fe("text-wrapper"),children:n})})})}Ue.Legend=function({children:e,variant:s="subheader-3"}){return(0,$.jsx)(Ae.E,{variant:s,color:"secondary",className:Fe("legend"),children:e})},Ue.Value=function({children:e,variant:s="subheader-2"}){return(0,$.jsx)(Ae.E,{variant:s,color:"secondary",className:Fe("value"),children:e})};var Ye=n(70043);const Ze=(0,g.cn)("ydb-cluster-dashboard");function We({children:e,title:s,size:n,className:t}){return(0,$.jsxs)(Be.A,{className:Ze("card",{size:n},t),size:n,interactive:!1,children:[s?(0,$.jsx)(Ae.E,{variant:"subheader-3",className:Ze("card-title"),children:s}):null,e]})}function qe({title:e,children:s,size:n,...t}){return(0,$.jsx)(We,{title:e,size:n,children:(0,$.jsx)(Ue,{...t,className:Ze("doughnut"),children:s})})}function Qe(){return(0,$.jsx)(We,{className:Ze("skeleton-wrapper"),children:(0,$.jsx)(Ye.E,{className:Ze("skeleton")})})}function He(){return(0,$.jsxs)(t.Fragment,{children:[(0,$.jsx)(Qe,{}),(0,$.jsx)(Qe,{}),(0,$.jsx)(Qe,{})]})}var Je=n(35736),Ke=n(57439),Xe=n(24543),es=n(46549);const ss=(0,g.cn)("ydb-disk-groups-stats"),ns=({stats:e,children:s})=>(0,$.jsx)("div",{className:ss(),children:(0,$.jsx)(Xe.u,{placement:["right"],pinOnClick:!0,content:(0,$.jsx)(ts,{stats:e}),children:s})});function ts({stats:e}){const{diskType:s,erasure:n,allocatedSize:t,availableSize:l}=e,r=(0,es.dd)(Math.max(t,l),2),a=(0,es.z3)({value:t,size:r}),o=(0,es.z3)({value:l,size:r}),i=Math.round(t/(t+l)*100),d=[{name:$e("disk-type"),content:s},{name:$e("erasure"),content:n},{name:$e("allocated"),content:a},{name:$e("available"),content:o},{name:$e("usage"),content:i+"%"}];return(0,$.jsx)(Ke.u,{items:d,className:ss("popup-content"),responsive:!0})}function ls({value:e,capacity:s,colorizeProgress:n=!0,warningThreshold:t,dangerThreshold:l,inverseColorize:r=!1,legendFormatter:a}){const o=parseFloat(String(e)),i=parseFloat(String(s));let d=o/i*100||0;d=d>100?100:d;const c=d<1?.5:d;return{status:(0,Je.w)({fillWidth:d,warningThreshold:t,dangerThreshold:l,colorizeProgress:n,inverseColorize:r}),percents:(0,se.l9)(d/100),legend:a({value:o,capacity:i}),fill:c}}const rs=["storage","tenant"];const as=e=>Object.values(e).reduce(((e,s)=>(Object.values(s).forEach((s=>{e+=s.createdGroups})),e)),0);function os({value:e,capacity:s}){let n=[];return n=s<1e4?[(0,se.ZV)(Math.round(e)),(0,se.ZV)(Math.round(s))]:(0,se.Nd)(e,s,void 0,"",!0),`${n[0]} / ${n[1]}\n${$e("context_cores")}`}function is({value:e,capacity:s,...n}){const{status:t,percents:l,legend:r,fill:a}=ls({value:e,capacity:s,legendFormatter:os,...n});return(0,$.jsxs)(qe,{status:t,fillWidth:a,title:$e("title_cpu"),children:[(0,$.jsx)(Ue.Legend,{children:r}),(0,$.jsx)(Ue.Value,{children:l})]})}function ds({value:e,capacity:s}){const n=(0,se.j9)(e,s,void 0,"\n");return`${n[0]} / ${n[1]}`}function cs({value:e,capacity:s,...n}){const{status:t,percents:l,legend:r,fill:a}=ls({value:e,capacity:s,legendFormatter:ds,...n});return(0,$.jsxs)(qe,{status:t,fillWidth:a,title:$e("title_memory"),children:[(0,$.jsx)(Ue.Legend,{children:r}),(0,$.jsx)(Ue.Value,{children:l})]})}function us({value:e,capacity:s}){const n=(0,se.j9)(e,s,void 0,"\n");return`${n[0]} / ${n[1]}`}function vs({value:e,capacity:s,...n}){const{status:t,percents:l,legend:r,fill:a}=ls({value:e,capacity:s,legendFormatter:us,...n});return(0,$.jsxs)(qe,{status:t,fillWidth:a,title:$e("title_storage"),children:[(0,$.jsx)(Ue.Legend,{children:r}),(0,$.jsx)(Ue.Value,{children:l})]})}function hs({value:e}){return(0,Pe.f8)(e)?(0,$.jsx)(Ae.E,{variant:"subheader-3",color:"secondary",children:(0,se.ZV)(e)}):null}function ps({cluster:e,...s}){return s.error?(0,$.jsx)(w.o,{error:s.error,className:Ze("error")}):(0,$.jsx)("div",{className:Ze(),children:(0,$.jsxs)(Ge.s,{gap:4,wrap:!0,children:[(0,$.jsx)(Ge.s,{gap:4,wrap:"nowrap",children:(0,$.jsx)(ms,{...s,cluster:e})}),(0,$.jsx)("div",{className:Ze("cards-container"),children:(0,$.jsx)(gs,{...s,cluster:e})})]})})}function ms({cluster:e,loading:s}){if(s)return(0,$.jsx)(He,{});const n=[];if((0,Me.L)(e)){const{CoresUsed:s,NumberOfCpus:t,CoresTotal:l}=e,r=null!==l&&void 0!==l?l:t;(0,Pe.f8)(s)&&(0,Pe.f8)(r)&&n.push((0,$.jsx)(is,{value:s,capacity:r},"cores"))}const{StorageTotal:t,StorageUsed:l}=e;(0,Pe.f8)(t)&&(0,Pe.f8)(l)&&n.push((0,$.jsx)(vs,{value:l,capacity:t},"storage"));const{MemoryTotal:r,MemoryUsed:a}=e;return(0,Pe.f8)(r)&&(0,Pe.f8)(a)&&n.push((0,$.jsx)(cs,{value:a,capacity:r},"memory")),n}function gs({cluster:e,groupStats:s={},loading:n}){if(n)return null;const l=[],r=function(e){const s=[];if((0,Me.L)(e)&&e.MapNodeRoles)for(const[n,l]of Object.entries(e.MapNodeRoles))rs.includes(n.toLowerCase())&&s.push((0,$.jsxs)(t.Fragment,{children:[n,": ",(0,se.ZV)(l)]},n));return s}(e);if(l.push((0,$.jsx)(We,{size:"l",title:$e("label_nodes"),children:(0,$.jsxs)(Ge.s,{gap:2,direction:"column",children:[(0,$.jsx)(hs,{value:null===e||void 0===e?void 0:e.NodesAlive}),null!==r&&void 0!==r&&r.length?(0,$.jsx)(Ie.Y,{tags:r,gap:3}):null]})},"roles")),Object.keys(s).length){const e=function(e){const s=[];return Object.entries(e).forEach((([e,n])=>{Object.values(n).forEach((n=>{s.push((0,$.jsxs)(ns,{stats:n,children:[e,": ",(0,se.ZV)(n.createdGroups)," /"," ",(0,se.ZV)(n.totalGroups)]},`${e}|${n.erasure}`))}))})),s}(s),n=as(s);l.push((0,$.jsx)(We,{size:"l",title:$e("label_storage-groups"),children:(0,$.jsxs)(Ge.s,{gap:2,direction:"column",children:[(0,$.jsx)(hs,{value:n}),(0,$.jsx)(Ie.Y,{tags:e,gap:3})]})},"groups"))}const a=function(e){var s;return(0,Me.L)(e)&&e.MapDataCenters?Object.keys(e.MapDataCenters):null===(s=e.DataCenters)||void 0===s?void 0:s.filter(Boolean)}(e);return null!==a&&void 0!==a&&a.length&&l.push((0,$.jsx)(We,{size:"l",title:$e("label_hosts"),children:(0,$.jsxs)(Ge.s,{gap:2,direction:"column",children:[(0,$.jsx)(hs,{value:null===e||void 0===e?void 0:e.Hosts}),(0,$.jsx)(Ie.Y,{tags:a,gap:3})]})},"hosts")),e.Tenants&&l.push((0,$.jsx)(We,{size:"l",title:$e("label_databases"),children:(0,$.jsx)(hs,{value:null===e||void 0===e?void 0:e.Tenants})},"tenants")),l}var js=n(42655);const xs=(0,g.cn)("cluster-info");var Ns=n(41650);function fs(){const{cores:e,logging:s}=(0,p.Zd)();return t.useMemo((()=>{const n=[],t=function(e){try{const s=(0,Ns.qF)(e);if(s&&"object"===typeof s&&"url"in s&&"string"===typeof s.url)return s.url}catch{}}(e),{logsUrl:l,sloLogsUrl:r}=function(e){try{const s=(0,Ns.qF)(e);if(s&&"object"===typeof s){return{logsUrl:"url"in s&&"string"===typeof s.url?s.url:void 0,sloLogsUrl:"slo_logs_url"in s&&"string"===typeof s.slo_logs_url?s.slo_logs_url:void 0}}}catch{}return{}}(s);return t&&n.push({title:$e("link_cores"),url:t}),l&&n.push({title:$e("link_logging"),url:l}),r&&n.push({title:$e("link_slo-logs"),url:r}),n}),[e,s])}var bs=n(15132);const ys=(0,g.cn)("ydb-nodes-state");function Cs({state:e,children:s}){return(0,$.jsx)("div",{className:ys({[e.toLowerCase()]:!0}),children:s})}const ks={Green:5,Blue:4,Yellow:3,Orange:2,Red:1,Grey:0},ws=(e,s)=>{const n=[];if((0,Me.L)(e)&&e.MapNodeStates){const s=Object.entries(e.MapNodeStates);s.sort(((e,s)=>ks[s[0]]-ks[e[0]]));const t=s.map((([e,s])=>(0,$.jsx)(Cs,{state:e,children:(0,se.ZV)(s)},e)));n.push({label:$e("label_nodes-state"),value:(0,$.jsx)(Ge.s,{gap:2,children:t})})}const l=(e=>{if((0,Me.L)(e)&&e.MapDataCenters)return Object.entries(e.MapDataCenters).map((([e,s])=>(0,$.jsxs)(t.Fragment,{children:[e,": ",(0,se.ZV)(s)]},e)))})(e);return null!==l&&void 0!==l&&l.length&&n.push({label:$e("label_dc"),value:(0,$.jsx)(Ie.Y,{tags:l,gap:2,className:xs("dc")})}),n.push({label:$e("label_load"),value:(0,$.jsx)(bs.O,{value:null===e||void 0===e?void 0:e.LoadAverage,capacity:null===e||void 0===e?void 0:e.NumberOfCpus})}),n.push(...s),n},Ts=({cluster:e,loading:s,error:n,additionalClusterProps:t={}})=>{const{info:l=[],links:r=[]}=t,a=fs(),o=r.concat(a),i=ws(null!==e&&void 0!==e?e:{},l);return(0,$.jsxs)("div",{className:xs(),children:[n?(0,$.jsx)(w.o,{error:n,className:xs("error")}):null,s?(0,$.jsx)(js.y,{className:xs("skeleton"),rows:4}):(0,$.jsxs)(Ge.s,{gap:10,wrap:"nowrap",children:[n&&!e?null:(0,$.jsxs)("div",{children:[(0,$.jsx)("div",{className:xs("section-title"),children:$e("title_info")}),(0,$.jsx)(L.u,{nameMaxWidth:200,children:i.map((({label:e,value:s})=>(0,$.jsx)(L.u.Item,{name:e,children:s},e)))})]}),o.length?(0,$.jsxs)("div",{children:[(0,$.jsx)("div",{className:xs("section-title"),children:$e("title_links")}),(0,$.jsx)(Ge.s,{direction:"column",gap:4,children:o.map((({title:e,url:s})=>(0,$.jsx)(G.K,{title:e,url:s},e)))})]}):null]})]})};var _s=n(87842);const Ss=(0,g.cn)("ydb-cluster");function Vs({additionalClusterProps:e,additionalTenantsProps:s,additionalNodesProps:n,additionalVersionsProps:g}){const y=t.useRef(null),C=(0,h.fp)(),k=(0,j.YQ)(),w=function(){const e=(0,j.YQ)(),s=(0,j.N4)((e=>e.cluster.defaultClusterTab)),n=(0,o.W5)(v.Ay.cluster),{activeTab:l}=(null===n||void 0===n?void 0:n.params)||{};let r;r=(0,_s.eC)(l)?l:s;return t.useEffect((()=>{r!==s&&e((0,p.Yv)(r))}),[r,s,e]),r}(),[{clusterName:T,backend:_}]=(0,i.useQueryParams)({clusterName:i.StringParam,backend:i.StringParam}),S=(0,j.N4)((e=>(0,p.zR)(e,null!==T&&void 0!==T?T:void 0))),{title:V}=(0,p.Zd)(),E=null!==V&&void 0!==V?V:S,{data:{clusterData:O={},groupsStats:L}={},isLoading:M,error:D}=p.Zh.useGetClusterInfoQuery(null!==T&&void 0!==T?T:void 0),z=D&&"object"===typeof D?D:void 0,A=(0,j.N4)((e=>(0,p.ds)(e,null!==T&&void 0!==T?T:void 0)));t.useEffect((()=>{k((0,m.g)("cluster",{}))}),[k]);const G=t.useMemo((()=>null!==g&&void 0!==g&&g.getVersionToColorMap?null===g||void 0===g?void 0:g.getVersionToColorMap():(0,x._n)(null===O||void 0===O?void 0:O.Versions)),[g,O]),I=t.useMemo((()=>_s.bn.find((({id:e})=>e===w))),[w]);return(0,$.jsxs)("div",{className:Ss(),ref:y,children:[(0,$.jsx)(a.mg,{defaultTitle:`${E} \u2014 YDB Monitoring`,titleTemplate:`%s \u2014 ${E} \u2014 YDB Monitoring`,children:I?(0,$.jsx)("title",{children:I.title}):null}),(0,$.jsx)("div",{className:Ss("header"),children:M?(0,$.jsx)(l.E,{className:Ss("title-skeleton")}):(0,$.jsx)(c.c,{size:"m",status:null===O||void 0===O?void 0:O.Overall,name:E,className:Ss("title")})}),(0,$.jsx)("div",{className:Ss("sticky-wrapper"),children:(0,$.jsx)(d.E,{className:Ss("auto-refresh-control")})}),C&&(0,$.jsx)(ps,{cluster:O,groupStats:L,loading:M,error:z||(null===O||void 0===O?void 0:O.error)}),(0,$.jsx)("div",{className:Ss("tabs-sticky-wrapper"),children:(0,$.jsx)(r.t,{size:"l",allowNotSelected:!0,activeTab:w,items:_s.bn,wrapTo:({id:e},s)=>{const n=(0,_s.a)(e,{clusterName:T,backend:_});return(0,$.jsx)(u.E,{to:n,onClick:()=>{k((0,p.Yv)(e))},children:s},e)}})}),(0,$.jsxs)(o.dO,{children:[(0,$.jsx)(o.qh,{path:(0,v.a3)((0,_s.a)(_s.Bi.overview)).pathname,children:(0,$.jsx)(Ts,{cluster:O,versionToColor:G,loading:M,error:z,additionalClusterProps:e})}),(0,$.jsx)(o.qh,{path:(0,v.a3)((0,_s.a)(_s.Bi.tablets)).pathname,children:(0,$.jsx)("div",{className:Ss("tablets"),children:(0,$.jsx)(b.Q,{loading:M,tablets:A,className:Ss("tablets-table")})})}),(0,$.jsx)(o.qh,{path:(0,v.a3)((0,_s.a)(_s.Bi.tenants)).pathname,children:(0,$.jsx)(te,{additionalTenantsProps:s})}),(0,$.jsx)(o.qh,{path:(0,v.a3)((0,_s.a)(_s.Bi.nodes)).pathname,children:(0,$.jsx)(N.G,{parentRef:y,additionalNodesProps:n})}),(0,$.jsx)(o.qh,{path:(0,v.a3)((0,_s.a)(_s.Bi.storage)).pathname,children:(0,$.jsx)(f.z,{parentRef:y})}),(0,$.jsx)(o.qh,{path:(0,v.a3)((0,_s.a)(_s.Bi.versions)).pathname,children:(0,$.jsx)(ze,{versionToColor:G,cluster:O})}),(0,$.jsx)(o.qh,{render:()=>(0,$.jsx)(o.rd,{to:(0,v.a3)((0,_s.a)(w))})})]})]})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2518.ac97d255.chunk.js b/ydb/core/viewer/monitoring/static/js/2518.ac97d255.chunk.js deleted file mode 100644 index 9912ff589d1c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2518.ac97d255.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2518.ac97d255.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2518],{52518:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>s,language:()=>o});var s={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\$\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"},{open:'"',close:'"'}],folding:{markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},o={defaultToken:"",tokenPostfix:".cs",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["extern","alias","using","bool","decimal","sbyte","byte","short","ushort","int","uint","long","ulong","char","float","double","object","dynamic","string","assembly","is","as","ref","out","this","base","new","typeof","void","checked","unchecked","default","delegate","var","const","if","else","switch","case","while","do","for","foreach","in","break","continue","goto","return","throw","try","catch","finally","lock","yield","from","let","where","join","on","equals","into","orderby","ascending","descending","select","group","by","namespace","partial","class","field","event","method","param","public","protected","internal","private","abstract","sealed","static","struct","readonly","volatile","virtual","override","params","get","set","add","remove","operator","true","false","implicit","explicit","interface","enum","null","async","await","fixed","sizeof","stackalloc","unsafe","nameof","when"],namespaceFollows:["namespace","using"],parenFollows:["if","for","while","switch","foreach","using","catch","when"],operators:["=","??","||","&&","|","^","&","==","!=","<=",">=","<<","+","-","*","/","%","!","~","++","--","+=","-=","*=","/=","%=","&=","|=","^=","<<=",">>=",">>","=>"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/[0-9_]*\.[0-9_]+([eE][\-+]?\d+)?[fFdD]?/,"number.float"],[/0[xX][0-9a-fA-F_]+/,"number.hex"],[/0[bB][01_]+/,"number.hex"],[/[0-9_]+/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,{token:"string.quote",next:"@string"}],[/\$\@"/,{token:"string.quote",next:"@litinterpstring"}],[/\@"/,{token:"string.quote",next:"@litstring"}],[/\$"/,{token:"string.quote",next:"@interpolatedstring"}],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],qualified:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],[/\./,"delimiter"],["","","@pop"]],namespace:[{include:"@whitespace"},[/[A-Z]\w*/,"namespace"],[/[\.=]/,"delimiter"],["","","@pop"]],comment:[[/[^\/*]+/,"comment"],["\\*/","comment","@pop"],[/[\/*]/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",next:"@pop"}]],litstring:[[/[^"]+/,"string"],[/""/,"string.escape"],[/"/,{token:"string.quote",next:"@pop"}]],litinterpstring:[[/[^"{]+/,"string"],[/""/,"string.escape"],[/{{/,"string.escape"],[/}}/,"string.escape"],[/{/,{token:"string.quote",next:"root.litinterpstring"}],[/"/,{token:"string.quote",next:"@pop"}]],interpolatedstring:[[/[^\\"{]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/{{/,"string.escape"],[/}}/,"string.escape"],[/{/,{token:"string.quote",next:"root.interpolatedstring"}],[/"/,{token:"string.quote",next:"@pop"}]],whitespace:[[/^[ \t\v\f]*#((r)|(load))(?=\s)/,"directive.csx"],[/^[ \t\v\f]*#\w.*$/,"namespace.cpp"],[/[ \t\v\f\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/25453.c8bfcbe1.chunk.js b/ydb/core/viewer/monitoring/static/js/25453.c8bfcbe1.chunk.js new file mode 100644 index 000000000000..8360cb4df861 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/25453.c8bfcbe1.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[25453],{25453:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"mk",weekdays:"\u043d\u0435\u0434\u0435\u043b\u0430_\u043f\u043e\u043d\u0435\u0434\u0435\u043b\u043d\u0438\u043a_\u0432\u0442\u043e\u0440\u043d\u0438\u043a_\u0441\u0440\u0435\u0434\u0430_\u0447\u0435\u0442\u0432\u0440\u0442\u043e\u043a_\u043f\u0435\u0442\u043e\u043a_\u0441\u0430\u0431\u043e\u0442\u0430".split("_"),months:"\u0458\u0430\u043d\u0443\u0430\u0440\u0438_\u0444\u0435\u0432\u0440\u0443\u0430\u0440\u0438_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0438\u043b_\u043c\u0430\u0458_\u0458\u0443\u043d\u0438_\u0458\u0443\u043b\u0438_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043f\u0442\u0435\u043c\u0432\u0440\u0438_\u043e\u043a\u0442\u043e\u043c\u0432\u0440\u0438_\u043d\u043e\u0435\u043c\u0432\u0440\u0438_\u0434\u0435\u043a\u0435\u043c\u0432\u0440\u0438".split("_"),weekStart:1,weekdaysShort:"\u043d\u0435\u0434_\u043f\u043e\u043d_\u0432\u0442\u043e_\u0441\u0440\u0435_\u0447\u0435\u0442_\u043f\u0435\u0442_\u0441\u0430\u0431".split("_"),monthsShort:"\u0458\u0430\u043d_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0458_\u0458\u0443\u043d_\u0458\u0443\u043b_\u0430\u0432\u0433_\u0441\u0435\u043f_\u043e\u043a\u0442_\u043d\u043e\u0435_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u043de_\u043fo_\u0432\u0442_\u0441\u0440_\u0447\u0435_\u043f\u0435_\u0441a".split("_"),ordinal:function(_){return _},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"D.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY H:mm",LLLL:"dddd, D MMMM YYYY H:mm"},relativeTime:{future:"\u043f\u043e\u0441\u043b\u0435 %s",past:"\u043f\u0440\u0435\u0434 %s",s:"\u043d\u0435\u043a\u043e\u043b\u043a\u0443 \u0441\u0435\u043a\u0443\u043d\u0434\u0438",m:"\u043c\u0438\u043d\u0443\u0442\u0430",mm:"%d \u043c\u0438\u043d\u0443\u0442\u0438",h:"\u0447\u0430\u0441",hh:"%d \u0447\u0430\u0441\u0430",d:"\u0434\u0435\u043d",dd:"%d \u0434\u0435\u043d\u0430",M:"\u043c\u0435\u0441\u0435\u0446",MM:"%d \u043c\u0435\u0441\u0435\u0446\u0438",y:"\u0433\u043e\u0434\u0438\u043d\u0430",yy:"%d \u0433\u043e\u0434\u0438\u043d\u0438"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/25604.54cb85d0.chunk.js b/ydb/core/viewer/monitoring/static/js/25604.54cb85d0.chunk.js new file mode 100644 index 000000000000..daf47c5467a2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/25604.54cb85d0.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[25604],{25604:(e,t,i)=>{i.d(t,{default:()=>n});var a=i(99475);const n=i.n(a)()},99475:e=>{function t(e){!function(e){for(var t=/\(\*(?:[^(*]|\((?!\*)|\*(?!\))|)*\*\)/.source,i=0;i<2;i++)t=t.replace(//g,(function(){return t}));t=t.replace(//g,"[]"),e.languages.coq={comment:RegExp(t),string:{pattern:/"(?:[^"]|"")*"(?!")/,greedy:!0},attribute:[{pattern:RegExp(/#\[(?:[^\[\]("]|"(?:[^"]|"")*"(?!")|\((?!\*)|)*\]/.source.replace(//g,(function(){return t}))),greedy:!0,alias:"attr-name",inside:{comment:RegExp(t),string:{pattern:/"(?:[^"]|"")*"(?!")/,greedy:!0},operator:/=/,punctuation:/^#\[|\]$|[,()]/}},{pattern:/\b(?:Cumulative|Global|Local|Monomorphic|NonCumulative|Polymorphic|Private|Program)\b/,alias:"attr-name"}],keyword:/\b(?:Abort|About|Add|Admit|Admitted|All|Arguments|As|Assumptions|Axiom|Axioms|Back|BackTo|Backtrace|BinOp|BinOpSpec|BinRel|Bind|Blacklist|Canonical|Case|Cd|Check|Class|Classes|Close|CoFixpoint|CoInductive|Coercion|Coercions|Collection|Combined|Compute|Conjecture|Conjectures|Constant|Constants|Constraint|Constructors|Context|Corollary|Create|CstOp|Custom|Cut|Debug|Declare|Defined|Definition|Delimit|Dependencies|Dependent|Derive|Diffs|Drop|Elimination|End|Entry|Equality|Eval|Example|Existential|Existentials|Existing|Export|Extern|Extraction|Fact|Fail|Field|File|Firstorder|Fixpoint|Flags|Focus|From|Funclass|Function|Functional|GC|Generalizable|Goal|Grab|Grammar|Graph|Guarded|Haskell|Heap|Hide|Hint|HintDb|Hints|Hypotheses|Hypothesis|IF|Identity|Immediate|Implicit|Implicits|Import|Include|Induction|Inductive|Infix|Info|Initial|InjTyp|Inline|Inspect|Instance|Instances|Intro|Intros|Inversion|Inversion_clear|JSON|Language|Left|Lemma|Let|Lia|Libraries|Library|Load|LoadPath|Locate|Ltac|Ltac2|ML|Match|Method|Minimality|Module|Modules|Morphism|Next|NoInline|Notation|Number|OCaml|Obligation|Obligations|Opaque|Open|Optimize|Parameter|Parameters|Parametric|Path|Paths|Prenex|Preterm|Primitive|Print|Profile|Projections|Proof|Prop|PropBinOp|PropOp|PropUOp|Property|Proposition|Pwd|Qed|Quit|Rec|Record|Recursive|Redirect|Reduction|Register|Relation|Remark|Remove|Require|Reserved|Reset|Resolve|Restart|Rewrite|Right|Ring|Rings|SProp|Saturate|Save|Scheme|Scope|Scopes|Search|SearchHead|SearchPattern|SearchRewrite|Section|Separate|Set|Setoid|Show|Signatures|Solve|Solver|Sort|Sortclass|Sorted|Spec|Step|Strategies|Strategy|String|Structure|SubClass|Subgraph|SuchThat|Tactic|Term|TestCompile|Theorem|Time|Timeout|To|Transparent|Type|Typeclasses|Types|Typing|UnOp|UnOpSpec|Undelimit|Undo|Unfocus|Unfocused|Unfold|Universe|Universes|Unshelve|Variable|Variables|Variant|Verbose|View|Visibility|Zify|_|apply|as|at|by|cofix|else|end|exists|exists2|fix|for|forall|fun|if|in|let|match|measure|move|removed|return|struct|then|using|wf|where|with)\b/,number:/\b(?:0x[a-f0-9][a-f0-9_]*(?:\.[a-f0-9_]+)?(?:p[+-]?\d[\d_]*)?|\d[\d_]*(?:\.[\d_]+)?(?:e[+-]?\d[\d_]*)?)\b/i,punct:{pattern:/@\{|\{\||\[=|:>/,alias:"punctuation"},operator:/\/\\|\\\/|\.{2,3}|:{1,2}=|\*\*|[-=]>|<(?:->?|[+:=>]|<:)|>(?:=|->)|\|[-|]?|[-!%&*+/<=>?@^~']/,punctuation:/\.\(|`\(|@\{|`\{|\{\||\[=|:>|[:.,;(){}\[\]]/}}(e)}e.exports=t,t.displayName="coq",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/25636.358f92b4.chunk.js b/ydb/core/viewer/monitoring/static/js/25636.358f92b4.chunk.js new file mode 100644 index 000000000000..e459fc7c9429 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/25636.358f92b4.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 25636.358f92b4.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[25636],{25636:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>s});var i={comments:{lineComment:"*"},brackets:[["[","]"],["(",")"]]},s={defaultToken:"invalid",ignoreCase:!0,tokenPostfix:".abap",keywords:["abap-source","abbreviated","abstract","accept","accepting","according","activation","actual","add","add-corresponding","adjacent","after","alias","aliases","align","all","allocate","alpha","analysis","analyzer","and","append","appendage","appending","application","archive","area","arithmetic","as","ascending","aspect","assert","assign","assigned","assigning","association","asynchronous","at","attributes","authority","authority-check","avg","back","background","backup","backward","badi","base","before","begin","between","big","binary","bintohex","bit","black","blank","blanks","blob","block","blocks","blue","bound","boundaries","bounds","boxed","break-point","buffer","by","bypassing","byte","byte-order","call","calling","case","cast","casting","catch","center","centered","chain","chain-input","chain-request","change","changing","channels","character","char-to-hex","check","checkbox","ci_","circular","class","class-coding","class-data","class-events","class-methods","class-pool","cleanup","clear","client","clob","clock","close","coalesce","code","coding","col_background","col_group","col_heading","col_key","col_negative","col_normal","col_positive","col_total","collect","color","column","columns","comment","comments","commit","common","communication","comparing","component","components","compression","compute","concat","concat_with_space","concatenate","cond","condense","condition","connect","connection","constants","context","contexts","continue","control","controls","conv","conversion","convert","copies","copy","corresponding","country","cover","cpi","create","creating","critical","currency","currency_conversion","current","cursor","cursor-selection","customer","customer-function","dangerous","data","database","datainfo","dataset","date","dats_add_days","dats_add_months","dats_days_between","dats_is_valid","daylight","dd/mm/yy","dd/mm/yyyy","ddmmyy","deallocate","decimal_shift","decimals","declarations","deep","default","deferred","define","defining","definition","delete","deleting","demand","department","descending","describe","destination","detail","dialog","directory","disconnect","display","display-mode","distinct","divide","divide-corresponding","division","do","dummy","duplicate","duplicates","duration","during","dynamic","dynpro","edit","editor-call","else","elseif","empty","enabled","enabling","encoding","end","endat","endcase","endcatch","endchain","endclass","enddo","endenhancement","end-enhancement-section","endexec","endform","endfunction","endian","endif","ending","endinterface","end-lines","endloop","endmethod","endmodule","end-of-definition","end-of-editing","end-of-file","end-of-page","end-of-selection","endon","endprovide","endselect","end-test-injection","end-test-seam","endtry","endwhile","endwith","engineering","enhancement","enhancement-point","enhancements","enhancement-section","entries","entry","enum","environment","equiv","errormessage","errors","escaping","event","events","exact","except","exception","exceptions","exception-table","exclude","excluding","exec","execute","exists","exit","exit-command","expand","expanding","expiration","explicit","exponent","export","exporting","extend","extended","extension","extract","fail","fetch","field","field-groups","fields","field-symbol","field-symbols","file","filter","filters","filter-table","final","find","first","first-line","fixed-point","fkeq","fkge","flush","font","for","form","format","forward","found","frame","frames","free","friends","from","function","functionality","function-pool","further","gaps","generate","get","giving","gkeq","gkge","global","grant","green","group","groups","handle","handler","harmless","hashed","having","hdb","header","headers","heading","head-lines","help-id","help-request","hextobin","hide","high","hint","hold","hotspot","icon","id","identification","identifier","ids","if","ignore","ignoring","immediately","implementation","implementations","implemented","implicit","import","importing","in","inactive","incl","include","includes","including","increment","index","index-line","infotypes","inheriting","init","initial","initialization","inner","inout","input","insert","instance","instances","instr","intensified","interface","interface-pool","interfaces","internal","intervals","into","inverse","inverted-date","is","iso","job","join","keep","keeping","kernel","key","keys","keywords","kind","language","last","late","layout","leading","leave","left","left-justified","leftplus","leftspace","legacy","length","let","level","levels","like","line","lines","line-count","linefeed","line-selection","line-size","list","listbox","list-processing","little","llang","load","load-of-program","lob","local","locale","locator","logfile","logical","log-point","long","loop","low","lower","lpad","lpi","ltrim","mail","main","major-id","mapping","margin","mark","mask","match","matchcode","max","maximum","medium","members","memory","mesh","message","message-id","messages","messaging","method","methods","min","minimum","minor-id","mm/dd/yy","mm/dd/yyyy","mmddyy","mode","modif","modifier","modify","module","move","move-corresponding","multiply","multiply-corresponding","name","nametab","native","nested","nesting","new","new-line","new-page","new-section","next","no","no-display","no-extension","no-gap","no-gaps","no-grouping","no-heading","no-scrolling","no-sign","no-title","no-topofpage","no-zero","node","nodes","non-unicode","non-unique","not","null","number","object","objects","obligatory","occurrence","occurrences","occurs","of","off","offset","ole","on","only","open","option","optional","options","or","order","other","others","out","outer","output","output-length","overflow","overlay","pack","package","pad","padding","page","pages","parameter","parameters","parameter-table","part","partially","pattern","percentage","perform","performing","person","pf1","pf10","pf11","pf12","pf13","pf14","pf15","pf2","pf3","pf4","pf5","pf6","pf7","pf8","pf9","pf-status","pink","places","pool","pos_high","pos_low","position","pragmas","precompiled","preferred","preserving","primary","print","print-control","priority","private","procedure","process","program","property","protected","provide","public","push","pushbutton","put","queue-only","quickinfo","radiobutton","raise","raising","range","ranges","read","reader","read-only","receive","received","receiver","receiving","red","redefinition","reduce","reduced","ref","reference","refresh","regex","reject","remote","renaming","replace","replacement","replacing","report","request","requested","reserve","reset","resolution","respecting","responsible","result","results","resumable","resume","retry","return","returncode","returning","returns","right","right-justified","rightplus","rightspace","risk","rmc_communication_failure","rmc_invalid_status","rmc_system_failure","role","rollback","rows","rpad","rtrim","run","sap","sap-spool","saving","scale_preserving","scale_preserving_scientific","scan","scientific","scientific_with_leading_zero","scroll","scroll-boundary","scrolling","search","secondary","seconds","section","select","selection","selections","selection-screen","selection-set","selection-sets","selection-table","select-options","send","separate","separated","set","shared","shift","short","shortdump-id","sign_as_postfix","single","size","skip","skipping","smart","some","sort","sortable","sorted","source","specified","split","spool","spots","sql","sqlscript","stable","stamp","standard","starting","start-of-editing","start-of-selection","state","statement","statements","static","statics","statusinfo","step-loop","stop","structure","structures","style","subkey","submatches","submit","subroutine","subscreen","subtract","subtract-corresponding","suffix","sum","summary","summing","supplied","supply","suppress","switch","switchstates","symbol","syncpoints","syntax","syntax-check","syntax-trace","system-call","system-exceptions","system-exit","tab","tabbed","table","tables","tableview","tabstrip","target","task","tasks","test","testing","test-injection","test-seam","text","textpool","then","throw","time","times","timestamp","timezone","tims_is_valid","title","titlebar","title-lines","to","tokenization","tokens","top-lines","top-of-page","trace-file","trace-table","trailing","transaction","transfer","transformation","translate","transporting","trmac","truncate","truncation","try","tstmp_add_seconds","tstmp_current_utctimestamp","tstmp_is_valid","tstmp_seconds_between","type","type-pool","type-pools","types","uline","unassign","under","unicode","union","unique","unit_conversion","unix","unpack","until","unwind","up","update","upper","user","user-command","using","utf-8","valid","value","value-request","values","vary","varying","verification-message","version","via","view","visible","wait","warning","when","whenever","where","while","width","window","windows","with","with-heading","without","with-title","word","work","write","writer","xml","xsd","yellow","yes","yymmdd","zero","zone","abap_system_timezone","abap_user_timezone","access","action","adabas","adjust_numbers","allow_precision_loss","allowed","amdp","applicationuser","as_geo_json","as400","associations","balance","behavior","breakup","bulk","cds","cds_client","check_before_save","child","clients","corr","corr_spearman","cross","cycles","datn_add_days","datn_add_months","datn_days_between","dats_from_datn","dats_tims_to_tstmp","dats_to_datn","db2","db6","ddl","dense_rank","depth","deterministic","discarding","entities","entity","error","failed","finalize","first_value","fltp_to_dec","following","fractional","full","graph","grouping","hierarchy","hierarchy_ancestors","hierarchy_ancestors_aggregate","hierarchy_descendants","hierarchy_descendants_aggregate","hierarchy_siblings","incremental","indicators","lag","last_value","lead","leaves","like_regexpr","link","locale_sap","lock","locks","many","mapped","matched","measures","median","mssqlnt","multiple","nodetype","ntile","nulls","occurrences_regexpr","one","operations","oracle","orphans","over","parent","parents","partition","pcre","period","pfcg_mapping","preceding","privileged","product","projection","rank","redirected","replace_regexpr","reported","response","responses","root","row","row_number","sap_system_date","save","schema","session","sets","shortdump","siblings","spantree","start","stddev","string_agg","subtotal","sybase","tims_from_timn","tims_to_timn","to_blob","to_clob","total","trace-entry","tstmp_to_dats","tstmp_to_dst","tstmp_to_tims","tstmpl_from_utcl","tstmpl_to_utcl","unbounded","utcl_add_seconds","utcl_current","utcl_seconds_between","uuid","var","verbatim"],builtinFunctions:["abs","acos","asin","atan","bit-set","boolc","boolx","ceil","char_off","charlen","cmax","cmin","concat_lines_of","contains","contains_any_not_of","contains_any_of","cos","cosh","count","count_any_not_of","count_any_of","dbmaxlen","distance","escape","exp","find_any_not_of","find_any_of","find_end","floor","frac","from_mixed","ipow","line_exists","line_index","log","log10","matches","nmax","nmin","numofchar","repeat","rescale","reverse","round","segment","shift_left","shift_right","sign","sin","sinh","sqrt","strlen","substring","substring_after","substring_before","substring_from","substring_to","tan","tanh","to_lower","to_mixed","to_upper","trunc","utclong_add","utclong_current","utclong_diff","xsdbool","xstrlen"],typeKeywords:["b","c","d","decfloat16","decfloat34","f","i","int8","n","p","s","string","t","utclong","x","xstring","any","clike","csequence","decfloat","numeric","simple","xsequence","accp","char","clnt","cuky","curr","datn","dats","d16d","d16n","d16r","d34d","d34n","d34r","dec","df16_dec","df16_raw","df34_dec","df34_raw","fltp","geom_ewkb","int1","int2","int4","lang","lchr","lraw","numc","quan","raw","rawstring","sstring","timn","tims","unit","utcl","df16_scl","df34_scl","prec","varc","abap_bool","abap_false","abap_true","abap_undefined","me","screen","space","super","sy","syst","table_line","*sys*"],builtinMethods:["class_constructor","constructor"],derivedTypes:["%CID","%CID_REF","%CONTROL","%DATA","%ELEMENT","%FAIL","%KEY","%MSG","%PARAM","%PID","%PID_ASSOC","%PID_PARENT","%_HINTS"],cdsLanguage:["@AbapAnnotation","@AbapCatalog","@AccessControl","@API","@ClientDependent","@ClientHandling","@CompatibilityContract","@DataAging","@EndUserText","@Environment","@LanguageDependency","@MappingRole","@Metadata","@MetadataExtension","@ObjectModel","@Scope","@Semantics","$EXTENSION","$SELF"],selectors:["->","->*","=>","~","~*"],operators:[" +"," -","/","*","**","div","mod","=","#","@","+=","-=","*=","/=","**=","&&=","?=","&","&&","bit-and","bit-not","bit-or","bit-xor","m","o","z","<"," >","<=",">=","<>","><","=<","=>","bt","byte-ca","byte-cn","byte-co","byte-cs","byte-na","byte-ns","ca","cn","co","cp","cs","eq","ge","gt","le","lt","na","nb","ne","np","ns","*/","*:","--","/*","//"],symbols:/[=>))*/,{cases:{"@typeKeywords":"type","@keywords":"keyword","@cdsLanguage":"annotation","@derivedTypes":"type","@builtinFunctions":"type","@builtinMethods":"type","@operators":"key","@default":"identifier"}}],[/<[\w]+>/,"identifier"],[/##[\w|_]+/,"comment"],{include:"@whitespace"},[/[:,.]/,"delimiter"],[/[{}()\[\]]/,"@brackets"],[/@symbols/,{cases:{"@selectors":"tag","@operators":"key","@default":""}}],[/'/,{token:"string",bracket:"@open",next:"@stringquote"}],[/`/,{token:"string",bracket:"@open",next:"@stringping"}],[/\|/,{token:"string",bracket:"@open",next:"@stringtemplate"}],[/\d+/,"number"]],stringtemplate:[[/[^\\\|]+/,"string"],[/\\\|/,"string"],[/\|/,{token:"string",bracket:"@close",next:"@pop"}]],stringping:[[/[^\\`]+/,"string"],[/`/,{token:"string",bracket:"@close",next:"@pop"}]],stringquote:[[/[^\\']+/,"string"],[/'/,{token:"string",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,""],[/^\*.*$/,"comment"],[/\".*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2518.ac97d255.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/25636.358f92b4.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2518.ac97d255.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/25636.358f92b4.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/2568.5bec7af3.chunk.js b/ydb/core/viewer/monitoring/static/js/2568.5bec7af3.chunk.js deleted file mode 100644 index 8edd3dadb65f..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2568.5bec7af3.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2568],{72568:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),n={1:"\u09e7",2:"\u09e8",3:"\u09e9",4:"\u09ea",5:"\u09eb",6:"\u09ec",7:"\u09ed",8:"\u09ee",9:"\u09ef",0:"\u09e6"},r={"\u09e7":"1","\u09e8":"2","\u09e9":"3","\u09ea":"4","\u09eb":"5","\u09ec":"6","\u09ed":"7","\u09ee":"8","\u09ef":"9","\u09e6":"0"},d={name:"bn-bd",weekdays:"\u09b0\u09ac\u09bf\u09ac\u09be\u09b0_\u09b8\u09cb\u09ae\u09ac\u09be\u09b0_\u09ae\u0999\u09cd\u0997\u09b2\u09ac\u09be\u09b0_\u09ac\u09c1\u09a7\u09ac\u09be\u09b0_\u09ac\u09c3\u09b9\u09b8\u09cd\u09aa\u09a4\u09bf\u09ac\u09be\u09b0_\u09b6\u09c1\u0995\u09cd\u09b0\u09ac\u09be\u09b0_\u09b6\u09a8\u09bf\u09ac\u09be\u09b0".split("_"),months:"\u099c\u09be\u09a8\u09c1\u09df\u09be\u09b0\u09bf_\u09ab\u09c7\u09ac\u09cd\u09b0\u09c1\u09df\u09be\u09b0\u09bf_\u09ae\u09be\u09b0\u09cd\u099a_\u098f\u09aa\u09cd\u09b0\u09bf\u09b2_\u09ae\u09c7_\u099c\u09c1\u09a8_\u099c\u09c1\u09b2\u09be\u0987_\u0986\u0997\u09b8\u09cd\u099f_\u09b8\u09c7\u09aa\u09cd\u099f\u09c7\u09ae\u09cd\u09ac\u09b0_\u0985\u0995\u09cd\u099f\u09cb\u09ac\u09b0_\u09a8\u09ad\u09c7\u09ae\u09cd\u09ac\u09b0_\u09a1\u09bf\u09b8\u09c7\u09ae\u09cd\u09ac\u09b0".split("_"),weekdaysShort:"\u09b0\u09ac\u09bf_\u09b8\u09cb\u09ae_\u09ae\u0999\u09cd\u0997\u09b2_\u09ac\u09c1\u09a7_\u09ac\u09c3\u09b9\u09b8\u09cd\u09aa\u09a4\u09bf_\u09b6\u09c1\u0995\u09cd\u09b0_\u09b6\u09a8\u09bf".split("_"),monthsShort:"\u099c\u09be\u09a8\u09c1_\u09ab\u09c7\u09ac\u09cd\u09b0\u09c1_\u09ae\u09be\u09b0\u09cd\u099a_\u098f\u09aa\u09cd\u09b0\u09bf\u09b2_\u09ae\u09c7_\u099c\u09c1\u09a8_\u099c\u09c1\u09b2\u09be\u0987_\u0986\u0997\u09b8\u09cd\u099f_\u09b8\u09c7\u09aa\u09cd\u099f_\u0985\u0995\u09cd\u099f\u09cb_\u09a8\u09ad\u09c7_\u09a1\u09bf\u09b8\u09c7".split("_"),weekdaysMin:"\u09b0\u09ac\u09bf_\u09b8\u09cb\u09ae_\u09ae\u0999\u09cd\u0997_\u09ac\u09c1\u09a7_\u09ac\u09c3\u09b9\u0983_\u09b6\u09c1\u0995\u09cd\u09b0_\u09b6\u09a8\u09bf".split("_"),weekStart:0,preparse:function(_){return _.replace(/[\u09e7\u09e8\u09e9\u09ea\u09eb\u09ec\u09ed\u09ee\u09ef\u09e6]/g,(function(_){return r[_]}))},postformat:function(_){return _.replace(/\d/g,(function(_){return n[_]}))},ordinal:function(_){var e=["\u0987","\u09b2\u09be","\u09b0\u09be","\u09a0\u09be","\u09b6\u09c7"],t=_%100;return"["+_+(e[(t-20)%10]||e[t]||e[0])+"]"},formats:{LT:"A h:mm \u09b8\u09ae\u09df",LTS:"A h:mm:ss \u09b8\u09ae\u09df",L:"DD/MM/YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6",LL:"D MMMM YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6",LLL:"D MMMM YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6, A h:mm \u09b8\u09ae\u09df",LLLL:"dddd, D MMMM YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6, A h:mm \u09b8\u09ae\u09df"},meridiem:function(_){return _<4?"\u09b0\u09be\u09a4":_<6?"\u09ad\u09cb\u09b0":_<12?"\u09b8\u0995\u09be\u09b2":_<15?"\u09a6\u09c1\u09aa\u09c1\u09b0":_<18?"\u09ac\u09bf\u0995\u09be\u09b2":_<20?"\u09b8\u09a8\u09cd\u09a7\u09cd\u09af\u09be":"\u09b0\u09be\u09a4"},relativeTime:{future:"%s \u09aa\u09b0\u09c7",past:"%s \u0986\u0997\u09c7",s:"\u0995\u09df\u09c7\u0995 \u09b8\u09c7\u0995\u09c7\u09a8\u09cd\u09a1",m:"\u098f\u0995 \u09ae\u09bf\u09a8\u09bf\u099f",mm:"%d \u09ae\u09bf\u09a8\u09bf\u099f",h:"\u098f\u0995 \u0998\u09a8\u09cd\u099f\u09be",hh:"%d \u0998\u09a8\u09cd\u099f\u09be",d:"\u098f\u0995 \u09a6\u09bf\u09a8",dd:"%d \u09a6\u09bf\u09a8",M:"\u098f\u0995 \u09ae\u09be\u09b8",MM:"%d \u09ae\u09be\u09b8",y:"\u098f\u0995 \u09ac\u099b\u09b0",yy:"%d \u09ac\u099b\u09b0"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2612.55127fa0.chunk.js b/ydb/core/viewer/monitoring/static/js/2612.55127fa0.chunk.js deleted file mode 100644 index af61f07a550d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2612.55127fa0.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2612],{42612:function(t,h,_){t.exports=function(t){"use strict";function h(t){return t&&"object"==typeof t&&"default"in t?t:{default:t}}var _=h(t),n={name:"vi",weekdays:"ch\u1ee7 nh\u1eadt_th\u1ee9 hai_th\u1ee9 ba_th\u1ee9 t\u01b0_th\u1ee9 n\u0103m_th\u1ee9 s\xe1u_th\u1ee9 b\u1ea3y".split("_"),months:"th\xe1ng 1_th\xe1ng 2_th\xe1ng 3_th\xe1ng 4_th\xe1ng 5_th\xe1ng 6_th\xe1ng 7_th\xe1ng 8_th\xe1ng 9_th\xe1ng 10_th\xe1ng 11_th\xe1ng 12".split("_"),weekStart:1,weekdaysShort:"CN_T2_T3_T4_T5_T6_T7".split("_"),monthsShort:"Th01_Th02_Th03_Th04_Th05_Th06_Th07_Th08_Th09_Th10_Th11_Th12".split("_"),weekdaysMin:"CN_T2_T3_T4_T5_T6_T7".split("_"),ordinal:function(t){return t},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM [n\u0103m] YYYY",LLL:"D MMMM [n\u0103m] YYYY HH:mm",LLLL:"dddd, D MMMM [n\u0103m] YYYY HH:mm",l:"DD/M/YYYY",ll:"D MMM YYYY",lll:"D MMM YYYY HH:mm",llll:"ddd, D MMM YYYY HH:mm"},relativeTime:{future:"%s t\u1edbi",past:"%s tr\u01b0\u1edbc",s:"v\xe0i gi\xe2y",m:"m\u1ed9t ph\xfat",mm:"%d ph\xfat",h:"m\u1ed9t gi\u1edd",hh:"%d gi\u1edd",d:"m\u1ed9t ng\xe0y",dd:"%d ng\xe0y",M:"m\u1ed9t th\xe1ng",MM:"%d th\xe1ng",y:"m\u1ed9t n\u0103m",yy:"%d n\u0103m"}};return _.default.locale(n,null,!0),n}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26214.42be0c73.chunk.js b/ydb/core/viewer/monitoring/static/js/26214.42be0c73.chunk.js new file mode 100644 index 000000000000..0f4a0d80cc04 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26214.42be0c73.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 26214.42be0c73.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26214],{26214:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>l,language:()=>m});var o,i,s=n(80781),r=Object.defineProperty,d=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,p=Object.prototype.hasOwnProperty,a=(e,t,n,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of c(t))p.call(e,i)||i===n||r(e,i,{get:()=>t[i],enumerable:!(o=d(t,i))||o.enumerable});return e},k={};a(k,o=s,"default"),i&&a(i,o,"default");var l={comments:{blockComment:["{/*","*/}"]},brackets:[["{","}"]],autoClosingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"\u201c",close:"\u201d"},{open:"\u2018",close:"\u2019"},{open:"`",close:"`"},{open:"{",close:"}"},{open:"(",close:")"},{open:"_",close:"_"},{open:"**",close:"**"},{open:"<",close:">"}],onEnterRules:[{beforeText:/^\s*- .+/,action:{indentAction:k.languages.IndentAction.None,appendText:"- "}},{beforeText:/^\s*\+ .+/,action:{indentAction:k.languages.IndentAction.None,appendText:"+ "}},{beforeText:/^\s*\* .+/,action:{indentAction:k.languages.IndentAction.None,appendText:"* "}},{beforeText:/^> /,action:{indentAction:k.languages.IndentAction.None,appendText:"> "}},{beforeText:/<\w+/,action:{indentAction:k.languages.IndentAction.Indent}},{beforeText:/\s+>\s*$/,action:{indentAction:k.languages.IndentAction.Indent}},{beforeText:/<\/\w+>/,action:{indentAction:k.languages.IndentAction.Outdent}},...Array.from({length:100},((e,t)=>({beforeText:new RegExp(`^${t}\\. .+`),action:{indentAction:k.languages.IndentAction.None,appendText:`${t+1}. `}})))]},m={defaultToken:"",tokenPostfix:".mdx",control:/[!#()*+.[\\\]_`{}\-]/,escapes:/\\@control/,tokenizer:{root:[[/^---$/,{token:"meta.content",next:"@frontmatter",nextEmbedded:"yaml"}],[/^\s*import/,{token:"keyword",next:"@import",nextEmbedded:"js"}],[/^\s*export/,{token:"keyword",next:"@export",nextEmbedded:"js"}],[/<\w+/,{token:"type.identifier",next:"@jsx"}],[/<\/?\w+>/,"type.identifier"],[/^(\s*)(>*\s*)(#{1,6}\s)/,[{token:"white"},{token:"comment"},{token:"keyword",next:"@header"}]],[/^(\s*)(>*\s*)([*+-])(\s+)/,["white","comment","keyword","white"]],[/^(\s*)(>*\s*)(\d{1,9}\.)(\s+)/,["white","comment","number","white"]],[/^(\s*)(>*\s*)(\d{1,9}\.)(\s+)/,["white","comment","number","white"]],[/^(\s*)(>*\s*)(-{3,}|\*{3,}|_{3,})$/,["white","comment","keyword"]],[/`{3,}(\s.*)?$/,{token:"string",next:"@codeblock_backtick"}],[/~{3,}(\s.*)?$/,{token:"string",next:"@codeblock_tilde"}],[/`{3,}(\S+).*$/,{token:"string",next:"@codeblock_highlight_backtick",nextEmbedded:"$1"}],[/~{3,}(\S+).*$/,{token:"string",next:"@codeblock_highlight_tilde",nextEmbedded:"$1"}],[/^(\s*)(-{4,})$/,["white","comment"]],[/^(\s*)(>+)/,["white","comment"]],{include:"content"}],content:[[/(\[)(.+)(]\()(.+)(\s+".*")(\))/,["","string.link","","type.identifier","string.link",""]],[/(\[)(.+)(]\()(.+)(\))/,["","type.identifier","","string.link",""]],[/(\[)(.+)(]\[)(.+)(])/,["","type.identifier","","type.identifier",""]],[/(\[)(.+)(]:\s+)(\S*)/,["","type.identifier","","string.link"]],[/(\[)(.+)(])/,["","type.identifier",""]],[/`.*`/,"variable.source"],[/_/,{token:"emphasis",next:"@emphasis_underscore"}],[/\*(?!\*)/,{token:"emphasis",next:"@emphasis_asterisk"}],[/\*\*/,{token:"strong",next:"@strong"}],[/{/,{token:"delimiter.bracket",next:"@expression",nextEmbedded:"js"}]],import:[[/'\s*(;|$)/,{token:"string",next:"@pop",nextEmbedded:"@pop"}]],expression:[[/{/,{token:"delimiter.bracket",next:"@expression"}],[/}/,{token:"delimiter.bracket",next:"@pop",nextEmbedded:"@pop"}]],export:[[/^\s*$/,{token:"delimiter.bracket",next:"@pop",nextEmbedded:"@pop"}]],jsx:[[/\s+/,""],[/(\w+)(=)("(?:[^"\\]|\\.)*")/,["attribute.name","operator","string"]],[/(\w+)(=)('(?:[^'\\]|\\.)*')/,["attribute.name","operator","string"]],[/(\w+(?=\s|>|={|$))/,["attribute.name"]],[/={/,{token:"delimiter.bracket",next:"@expression",nextEmbedded:"js"}],[/>/,{token:"type.identifier",next:"@pop"}]],header:[[/.$/,{token:"keyword",next:"@pop"}],{include:"content"},[/./,{token:"keyword"}]],strong:[[/\*\*/,{token:"strong",next:"@pop"}],{include:"content"},[/./,{token:"strong"}]],emphasis_underscore:[[/_/,{token:"emphasis",next:"@pop"}],{include:"content"},[/./,{token:"emphasis"}]],emphasis_asterisk:[[/\*(?!\*)/,{token:"emphasis",next:"@pop"}],{include:"content"},[/./,{token:"emphasis"}]],frontmatter:[[/^---$/,{token:"meta.content",nextEmbedded:"@pop",next:"@pop"}]],codeblock_highlight_backtick:[[/\s*`{3,}\s*$/,{token:"string",next:"@pop",nextEmbedded:"@pop"}],[/.*$/,"variable.source"]],codeblock_highlight_tilde:[[/\s*~{3,}\s*$/,{token:"string",next:"@pop",nextEmbedded:"@pop"}],[/.*$/,"variable.source"]],codeblock_backtick:[[/\s*`{3,}\s*$/,{token:"string",next:"@pop"}],[/.*$/,"variable.source"]],codeblock_tilde:[[/\s*~{3,}\s*$/,{token:"string",next:"@pop"}],[/.*$/,"variable.source"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2726.e753cb7c.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/26214.42be0c73.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2726.e753cb7c.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/26214.42be0c73.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/2626.a5b0d58c.chunk.js b/ydb/core/viewer/monitoring/static/js/2626.a5b0d58c.chunk.js deleted file mode 100644 index 84cf1f1e72b2..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2626.a5b0d58c.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2626],{22626:function(e,_,t){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=_(e),a={name:"bs",weekdays:"nedjelja_ponedjeljak_utorak_srijeda_\u010detvrtak_petak_subota".split("_"),months:"januar_februar_mart_april_maj_juni_juli_august_septembar_oktobar_novembar_decembar".split("_"),weekStart:1,weekdaysShort:"ned._pon._uto._sri._\u010det._pet._sub.".split("_"),monthsShort:"jan._feb._mar._apr._maj._jun._jul._aug._sep._okt._nov._dec.".split("_"),weekdaysMin:"ne_po_ut_sr_\u010de_pe_su".split("_"),ordinal:function(e){return e},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm"}};return t.default.locale(a,null,!0),a}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26324.10b41523.chunk.js b/ydb/core/viewer/monitoring/static/js/26324.10b41523.chunk.js new file mode 100644 index 000000000000..aafcb37081bc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26324.10b41523.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26324],{26324:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),t={name:"id",weekdays:"Minggu_Senin_Selasa_Rabu_Kamis_Jumat_Sabtu".split("_"),months:"Januari_Februari_Maret_April_Mei_Juni_Juli_Agustus_September_Oktober_November_Desember".split("_"),weekdaysShort:"Min_Sen_Sel_Rab_Kam_Jum_Sab".split("_"),monthsShort:"Jan_Feb_Mar_Apr_Mei_Jun_Jul_Agt_Sep_Okt_Nov_Des".split("_"),weekdaysMin:"Mg_Sn_Sl_Rb_Km_Jm_Sb".split("_"),weekStart:1,formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [pukul] HH.mm",LLLL:"dddd, D MMMM YYYY [pukul] HH.mm"},relativeTime:{future:"dalam %s",past:"%s yang lalu",s:"beberapa detik",m:"semenit",mm:"%d menit",h:"sejam",hh:"%d jam",d:"sehari",dd:"%d hari",M:"sebulan",MM:"%d bulan",y:"setahun",yy:"%d tahun"},ordinal:function(e){return e+"."}};return a.default.locale(t,null,!0),t}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26327.62bdac9a.chunk.js b/ydb/core/viewer/monitoring/static/js/26327.62bdac9a.chunk.js new file mode 100644 index 000000000000..aeb4a7b46bfe --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26327.62bdac9a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26327],{3899:e=>{function a(e){!function(e){var a=e.languages.javadoclike={parameter:{pattern:/(^[\t ]*(?:\/{3}|\*|\/\*\*)\s*@(?:arg|arguments|param)\s+)\w+/m,lookbehind:!0},keyword:{pattern:/(^[\t ]*(?:\/{3}|\*|\/\*\*)\s*|\{)@[a-z][a-zA-Z-]+\b/m,lookbehind:!0},punctuation:/[{}]/};Object.defineProperty(a,"addSupport",{value:function(a,t){"string"===typeof a&&(a=[a]),a.forEach((function(a){!function(a,t){var n="doc-comment",i=e.languages[a];if(i){var s=i[n];if(!s){var r={};r[n]={pattern:/(^|[^\\])\/\*\*[^/][\s\S]*?(?:\*\/|$)/,lookbehind:!0,alias:"comment"},s=(i=e.languages.insertBefore(a,"comment",r))[n]}if(s instanceof RegExp&&(s=i[n]={pattern:s}),Array.isArray(s))for(var o=0,l=s.length;o{t.d(a,{default:()=>i});var n=t(40242);const i=t.n(n)()},32098:(e,a,t)=>{var n=t(51572);function i(e){e.register(n),function(e){var a=/\/\*[\s\S]*?\*\/|\/\/.*|#(?!\[).*/,t=[{pattern:/\b(?:false|true)\b/i,alias:"boolean"},{pattern:/(::\s*)\b[a-z_]\w*\b(?!\s*\()/i,greedy:!0,lookbehind:!0},{pattern:/(\b(?:case|const)\s+)\b[a-z_]\w*(?=\s*[;=])/i,greedy:!0,lookbehind:!0},/\b(?:null)\b/i,/\b[A-Z_][A-Z0-9_]*\b(?!\s*\()/],n=/\b0b[01]+(?:_[01]+)*\b|\b0o[0-7]+(?:_[0-7]+)*\b|\b0x[\da-f]+(?:_[\da-f]+)*\b|(?:\b\d+(?:_\d+)*\.?(?:\d+(?:_\d+)*)?|\B\.\d+)(?:e[+-]?\d+)?/i,i=/|\?\?=?|\.{3}|\??->|[!=]=?=?|::|\*\*=?|--|\+\+|&&|\|\||<<|>>|[?~]|[/^|%*&<>.+-]=?/,s=/[{}\[\](),:;]/;e.languages.php={delimiter:{pattern:/\?>$|^<\?(?:php(?=\s)|=)?/i,alias:"important"},comment:a,variable:/\$+(?:\w+\b|(?=\{))/,package:{pattern:/(namespace\s+|use\s+(?:function\s+)?)(?:\\?\b[a-z_]\w*)+\b(?!\\)/i,lookbehind:!0,inside:{punctuation:/\\/}},"class-name-definition":{pattern:/(\b(?:class|enum|interface|trait)\s+)\b[a-z_]\w*(?!\\)\b/i,lookbehind:!0,alias:"class-name"},"function-definition":{pattern:/(\bfunction\s+)[a-z_]\w*(?=\s*\()/i,lookbehind:!0,alias:"function"},keyword:[{pattern:/(\(\s*)\b(?:array|bool|boolean|float|int|integer|object|string)\b(?=\s*\))/i,alias:"type-casting",greedy:!0,lookbehind:!0},{pattern:/([(,?]\s*)\b(?:array(?!\s*\()|bool|callable|(?:false|null)(?=\s*\|)|float|int|iterable|mixed|object|self|static|string)\b(?=\s*\$)/i,alias:"type-hint",greedy:!0,lookbehind:!0},{pattern:/(\)\s*:\s*(?:\?\s*)?)\b(?:array(?!\s*\()|bool|callable|(?:false|null)(?=\s*\|)|float|int|iterable|mixed|object|self|static|string|void)\b/i,alias:"return-type",greedy:!0,lookbehind:!0},{pattern:/\b(?:array(?!\s*\()|bool|float|int|iterable|mixed|object|string|void)\b/i,alias:"type-declaration",greedy:!0},{pattern:/(\|\s*)(?:false|null)\b|\b(?:false|null)(?=\s*\|)/i,alias:"type-declaration",greedy:!0,lookbehind:!0},{pattern:/\b(?:parent|self|static)(?=\s*::)/i,alias:"static-context",greedy:!0},{pattern:/(\byield\s+)from\b/i,lookbehind:!0},/\bclass\b/i,{pattern:/((?:^|[^\s>:]|(?:^|[^-])>|(?:^|[^:]):)\s*)\b(?:abstract|and|array|as|break|callable|case|catch|clone|const|continue|declare|default|die|do|echo|else|elseif|empty|enddeclare|endfor|endforeach|endif|endswitch|endwhile|enum|eval|exit|extends|final|finally|fn|for|foreach|function|global|goto|if|implements|include|include_once|instanceof|insteadof|interface|isset|list|match|namespace|new|or|parent|print|private|protected|public|require|require_once|return|self|static|switch|throw|trait|try|unset|use|var|while|xor|yield|__halt_compiler)\b/i,lookbehind:!0}],"argument-name":{pattern:/([(,]\s+)\b[a-z_]\w*(?=\s*:(?!:))/i,lookbehind:!0},"class-name":[{pattern:/(\b(?:extends|implements|instanceof|new(?!\s+self|\s+static))\s+|\bcatch\s*\()\b[a-z_]\w*(?!\\)\b/i,greedy:!0,lookbehind:!0},{pattern:/(\|\s*)\b[a-z_]\w*(?!\\)\b/i,greedy:!0,lookbehind:!0},{pattern:/\b[a-z_]\w*(?!\\)\b(?=\s*\|)/i,greedy:!0},{pattern:/(\|\s*)(?:\\?\b[a-z_]\w*)+\b/i,alias:"class-name-fully-qualified",greedy:!0,lookbehind:!0,inside:{punctuation:/\\/}},{pattern:/(?:\\?\b[a-z_]\w*)+\b(?=\s*\|)/i,alias:"class-name-fully-qualified",greedy:!0,inside:{punctuation:/\\/}},{pattern:/(\b(?:extends|implements|instanceof|new(?!\s+self\b|\s+static\b))\s+|\bcatch\s*\()(?:\\?\b[a-z_]\w*)+\b(?!\\)/i,alias:"class-name-fully-qualified",greedy:!0,lookbehind:!0,inside:{punctuation:/\\/}},{pattern:/\b[a-z_]\w*(?=\s*\$)/i,alias:"type-declaration",greedy:!0},{pattern:/(?:\\?\b[a-z_]\w*)+(?=\s*\$)/i,alias:["class-name-fully-qualified","type-declaration"],greedy:!0,inside:{punctuation:/\\/}},{pattern:/\b[a-z_]\w*(?=\s*::)/i,alias:"static-context",greedy:!0},{pattern:/(?:\\?\b[a-z_]\w*)+(?=\s*::)/i,alias:["class-name-fully-qualified","static-context"],greedy:!0,inside:{punctuation:/\\/}},{pattern:/([(,?]\s*)[a-z_]\w*(?=\s*\$)/i,alias:"type-hint",greedy:!0,lookbehind:!0},{pattern:/([(,?]\s*)(?:\\?\b[a-z_]\w*)+(?=\s*\$)/i,alias:["class-name-fully-qualified","type-hint"],greedy:!0,lookbehind:!0,inside:{punctuation:/\\/}},{pattern:/(\)\s*:\s*(?:\?\s*)?)\b[a-z_]\w*(?!\\)\b/i,alias:"return-type",greedy:!0,lookbehind:!0},{pattern:/(\)\s*:\s*(?:\?\s*)?)(?:\\?\b[a-z_]\w*)+\b(?!\\)/i,alias:["class-name-fully-qualified","return-type"],greedy:!0,lookbehind:!0,inside:{punctuation:/\\/}}],constant:t,function:{pattern:/(^|[^\\\w])\\?[a-z_](?:[\w\\]*\w)?(?=\s*\()/i,lookbehind:!0,inside:{punctuation:/\\/}},property:{pattern:/(->\s*)\w+/,lookbehind:!0},number:n,operator:i,punctuation:s};var r={pattern:/\{\$(?:\{(?:\{[^{}]+\}|[^{}]+)\}|[^{}])+\}|(^|[^\\{])\$+(?:\w+(?:\[[^\r\n\[\]]+\]|->\w+)?)/,lookbehind:!0,inside:e.languages.php},o=[{pattern:/<<<'([^']+)'[\r\n](?:.*[\r\n])*?\1;/,alias:"nowdoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<<'[^']+'|[a-z_]\w*;$/i,alias:"symbol",inside:{punctuation:/^<<<'?|[';]$/}}}},{pattern:/<<<(?:"([^"]+)"[\r\n](?:.*[\r\n])*?\1;|([a-z_]\w*)[\r\n](?:.*[\r\n])*?\2;)/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<<(?:"[^"]+"|[a-z_]\w*)|[a-z_]\w*;$/i,alias:"symbol",inside:{punctuation:/^<<<"?|[";]$/}},interpolation:r}},{pattern:/`(?:\\[\s\S]|[^\\`])*`/,alias:"backtick-quoted-string",greedy:!0},{pattern:/'(?:\\[\s\S]|[^\\'])*'/,alias:"single-quoted-string",greedy:!0},{pattern:/"(?:\\[\s\S]|[^\\"])*"/,alias:"double-quoted-string",greedy:!0,inside:{interpolation:r}}];e.languages.insertBefore("php","variable",{string:o,attribute:{pattern:/#\[(?:[^"'\/#]|\/(?![*/])|\/\/.*$|#(?!\[).*$|\/\*(?:[^*]|\*(?!\/))*\*\/|"(?:\\[\s\S]|[^\\"])*"|'(?:\\[\s\S]|[^\\'])*')+\](?=\s*[a-z$#])/im,greedy:!0,inside:{"attribute-content":{pattern:/^(#\[)[\s\S]+(?=\]$)/,lookbehind:!0,inside:{comment:a,string:o,"attribute-class-name":[{pattern:/([^:]|^)\b[a-z_]\w*(?!\\)\b/i,alias:"class-name",greedy:!0,lookbehind:!0},{pattern:/([^:]|^)(?:\\?\b[a-z_]\w*)+/i,alias:["class-name","class-name-fully-qualified"],greedy:!0,lookbehind:!0,inside:{punctuation:/\\/}}],constant:t,number:n,operator:i,punctuation:s}},delimiter:{pattern:/^#\[|\]$/,alias:"punctuation"}}}}),e.hooks.add("before-tokenize",(function(a){if(/<\?/.test(a.code)){e.languages["markup-templating"].buildPlaceholders(a,"php",/<\?(?:[^"'/#]|\/(?![*/])|("|')(?:\\[\s\S]|(?!\1)[^\\])*\1|(?:\/\/|#(?!\[))(?:[^?\n\r]|\?(?!>))*(?=$|\?>|[\r\n])|#\[|\/\*(?:[^*]|\*(?!\/))*(?:\*\/|$))*?(?:\?>|$)/g)}})),e.hooks.add("after-tokenize",(function(a){e.languages["markup-templating"].tokenizePlaceholders(a,"php")}))}(e)}e.exports=i,i.displayName="php",i.aliases=[]},40242:(e,a,t)=>{var n=t(32098),i=t(3899);function s(e){e.register(n),e.register(i),function(e){var a=/(?:\b[a-zA-Z]\w*|[|\\[\]])+/.source;e.languages.phpdoc=e.languages.extend("javadoclike",{parameter:{pattern:RegExp("(@(?:global|param|property(?:-read|-write)?|var)\\s+(?:"+a+"\\s+)?)\\$\\w+"),lookbehind:!0}}),e.languages.insertBefore("phpdoc","keyword",{"class-name":[{pattern:RegExp("(@(?:global|package|param|property(?:-read|-write)?|return|subpackage|throws|var)\\s+)"+a),lookbehind:!0,inside:{keyword:/\b(?:array|bool|boolean|callback|double|false|float|int|integer|mixed|null|object|resource|self|string|true|void)\b/,punctuation:/[|\\[\]()]/}}]}),e.languages.javadoclike.addSupport("php",e.languages.phpdoc)}(e)}e.exports=s,s.displayName="phpdoc",s.aliases=[]},51572:e=>{function a(e){!function(e){function a(e,a){return"___"+e.toUpperCase()+a+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,n,i,s){if(t.language===n){var r=t.tokenStack=[];t.code=t.code.replace(i,(function(e){if("function"===typeof s&&!s(e))return e;for(var i,o=r.length;-1!==t.code.indexOf(i=a(n,o));)++o;return r[o]=e,i})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,n){if(t.language===n&&t.tokenStack){t.grammar=e.languages[n];var i=0,s=Object.keys(t.tokenStack);!function r(o){for(var l=0;l=s.length);l++){var d=o[l];if("string"===typeof d||d.content&&"string"===typeof d.content){var p=s[i],c=t.tokenStack[p],u="string"===typeof d?d:d.content,b=a(n,p),g=u.indexOf(b);if(g>-1){++i;var f=u.substring(0,g),y=new e.Token(n,e.tokenize(c,t.grammar),"language-"+n,c),m=u.substring(g+b.length),h=[];f&&h.push.apply(h,r([f])),h.push(y),m&&h.push.apply(h,r([m])),"string"===typeof d?o.splice.apply(o,[l,1].concat(h)):d.content=h}}else d.content&&r(d.content)}return o}(t.tokens)}}}})}(e)}e.exports=a,a.displayName="markupTemplating",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26358.23555994.chunk.js b/ydb/core/viewer/monitoring/static/js/26358.23555994.chunk.js new file mode 100644 index 000000000000..b258ebff3e71 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26358.23555994.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26358],{26358:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),n={name:"mr",weekdays:"\u0930\u0935\u093f\u0935\u093e\u0930_\u0938\u094b\u092e\u0935\u093e\u0930_\u092e\u0902\u0917\u0933\u0935\u093e\u0930_\u092c\u0941\u0927\u0935\u093e\u0930_\u0917\u0941\u0930\u0942\u0935\u093e\u0930_\u0936\u0941\u0915\u094d\u0930\u0935\u093e\u0930_\u0936\u0928\u093f\u0935\u093e\u0930".split("_"),months:"\u091c\u093e\u0928\u0947\u0935\u093e\u0930\u0940_\u092b\u0947\u092c\u094d\u0930\u0941\u0935\u093e\u0930\u0940_\u092e\u093e\u0930\u094d\u091a_\u090f\u092a\u094d\u0930\u093f\u0932_\u092e\u0947_\u091c\u0942\u0928_\u091c\u0941\u0932\u0948_\u0911\u0917\u0938\u094d\u091f_\u0938\u092a\u094d\u091f\u0947\u0902\u092c\u0930_\u0911\u0915\u094d\u091f\u094b\u092c\u0930_\u0928\u094b\u0935\u094d\u0939\u0947\u0902\u092c\u0930_\u0921\u093f\u0938\u0947\u0902\u092c\u0930".split("_"),weekdaysShort:"\u0930\u0935\u093f_\u0938\u094b\u092e_\u092e\u0902\u0917\u0933_\u092c\u0941\u0927_\u0917\u0941\u0930\u0942_\u0936\u0941\u0915\u094d\u0930_\u0936\u0928\u093f".split("_"),monthsShort:"\u091c\u093e\u0928\u0947._\u092b\u0947\u092c\u094d\u0930\u0941._\u092e\u093e\u0930\u094d\u091a._\u090f\u092a\u094d\u0930\u093f._\u092e\u0947._\u091c\u0942\u0928._\u091c\u0941\u0932\u0948._\u0911\u0917._\u0938\u092a\u094d\u091f\u0947\u0902._\u0911\u0915\u094d\u091f\u094b._\u0928\u094b\u0935\u094d\u0939\u0947\u0902._\u0921\u093f\u0938\u0947\u0902.".split("_"),weekdaysMin:"\u0930_\u0938\u094b_\u092e\u0902_\u092c\u0941_\u0917\u0941_\u0936\u0941_\u0936".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm \u0935\u093e\u091c\u0924\u093e",LTS:"A h:mm:ss \u0935\u093e\u091c\u0924\u093e",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm \u0935\u093e\u091c\u0924\u093e",LLLL:"dddd, D MMMM YYYY, A h:mm \u0935\u093e\u091c\u0924\u093e"}};return t.default.locale(n,null,!0),n}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26411.07f03301.chunk.js b/ydb/core/viewer/monitoring/static/js/26411.07f03301.chunk.js new file mode 100644 index 000000000000..bab22e9d8be4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26411.07f03301.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26411],{26411:(e,t,a)=>{a.d(t,{default:()=>i});var r=a(46222);const i=a.n(r)()},46222:e=>{function t(e){!function(e){e.languages.pure={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?\*\//,lookbehind:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0},/#!.+/],"inline-lang":{pattern:/%<[\s\S]+?%>/,greedy:!0,inside:{lang:{pattern:/(^%< *)-\*-.+?-\*-/,lookbehind:!0,alias:"comment"},delimiter:{pattern:/^%<.*|%>$/,alias:"punctuation"}}},string:{pattern:/"(?:\\.|[^"\\\r\n])*"/,greedy:!0},number:{pattern:/((?:\.\.)?)(?:\b(?:inf|nan)\b|\b0x[\da-f]+|(?:\b(?:0b)?\d+(?:\.\d+)?|\B\.\d+)(?:e[+-]?\d+)?L?)/i,lookbehind:!0},keyword:/\b(?:NULL|ans|break|bt|case|catch|cd|clear|const|def|del|dump|else|end|exit|extern|false|force|help|if|infix[lr]?|interface|let|ls|mem|namespace|nonfix|of|otherwise|outfix|override|postfix|prefix|private|public|pwd|quit|run|save|show|stats|then|throw|trace|true|type|underride|using|when|with)\b/,function:/\b(?:abs|add_(?:addr|constdef|(?:fundef|interface|macdef|typedef)(?:_at)?|vardef)|all|any|applp?|arity|bigintp?|blob(?:_crc|_size|p)?|boolp?|byte_c?string(?:_pointer)?|byte_(?:matrix|pointer)|calloc|cat|catmap|ceil|char[ps]?|check_ptrtag|chr|clear_sentry|clearsym|closurep?|cmatrixp?|cols?|colcat(?:map)?|colmap|colrev|colvector(?:p|seq)?|complex(?:_float_(?:matrix|pointer)|_matrix(?:_view)?|_pointer|p)?|conj|cookedp?|cst|cstring(?:_(?:dup|list|vector))?|curry3?|cyclen?|del_(?:constdef|fundef|interface|macdef|typedef|vardef)|delete|diag(?:mat)?|dim|dmatrixp?|do|double(?:_matrix(?:_view)?|_pointer|p)?|dowith3?|drop|dropwhile|eval(?:cmd)?|exactp|filter|fix|fixity|flip|float(?:_matrix|_pointer)|floor|fold[lr]1?|frac|free|funp?|functionp?|gcd|get(?:_(?:byte|constdef|double|float|fundef|int(?:64)?|interface(?:_typedef)?|long|macdef|pointer|ptrtag|sentry|short|string|typedef|vardef))?|globsym|hash|head|id|im|imatrixp?|index|inexactp|infp|init|insert|int(?:_matrix(?:_view)?|_pointer|p)?|int64_(?:matrix|pointer)|integerp?|iteraten?|iterwhile|join|keys?|lambdap?|last(?:err(?:pos)?)?|lcd|list[2p]?|listmap|make_ptrtag|malloc|map|matcat|matrixp?|max|member|min|nanp|nargs|nmatrixp?|null|numberp?|ord|pack(?:ed)?|pointer(?:_cast|_tag|_type|p)?|pow|pred|ptrtag|put(?:_(?:byte|double|float|int(?:64)?|long|pointer|short|string))?|rationalp?|re|realp?|realloc|recordp?|redim|reduce(?:_with)?|refp?|repeatn?|reverse|rlistp?|round|rows?|rowcat(?:map)?|rowmap|rowrev|rowvector(?:p|seq)?|same|scan[lr]1?|sentry|sgn|short_(?:matrix|pointer)|slice|smatrixp?|sort|split|str|strcat|stream|stride|string(?:_(?:dup|list|vector)|p)?|subdiag(?:mat)?|submat|subseq2?|substr|succ|supdiag(?:mat)?|symbolp?|tail|take|takewhile|thunkp?|transpose|trunc|tuplep?|typep|ubyte|uint(?:64)?|ulong|uncurry3?|unref|unzip3?|update|ushort|vals?|varp?|vector(?:p|seq)?|void|zip3?|zipwith3?)\b/,special:{pattern:/\b__[a-z]+__\b/i,alias:"builtin"},operator:/(?:[!"#$%&'*+,\-.\/:<=>?@\\^`|~\u00a1-\u00bf\u00d7-\u00f7\u20d0-\u2bff]|\b_+\b)+|\b(?:and|div|mod|not|or)\b/,punctuation:/[(){}\[\];,|]/};var t=/%< *-\*- *\d* *-\*-[\s\S]+?%>/.source;["c",{lang:"c++",alias:"cpp"},"fortran"].forEach((function(a){var r=a;if("string"!==typeof a&&(r=a.alias,a=a.lang),e.languages[r]){var i={};i["inline-lang-"+r]={pattern:RegExp(t.replace("",a.replace(/([.+*?\/\\(){}\[\]])/g,"\\$1")),"i"),inside:e.util.clone(e.languages.pure["inline-lang"].inside)},i["inline-lang-"+r].inside.rest=e.util.clone(e.languages[r]),e.languages.insertBefore("pure","inline-lang",i)}})),e.languages.c&&(e.languages.pure["inline-lang"].inside.rest=e.util.clone(e.languages.c))}(e)}e.exports=t,t.displayName="pure",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2656.6cdcd805.chunk.js b/ydb/core/viewer/monitoring/static/js/2656.6cdcd805.chunk.js new file mode 100644 index 000000000000..a991b3ff760a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/2656.6cdcd805.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2656],{2656:(e,n,t)=>{t.d(n,{default:()=>a});var i=t(59129);const a=t.n(i)()},59129:e=>{function n(e){e.languages.gn={comment:{pattern:/#.*/,greedy:!0},"string-literal":{pattern:/(^|[^\\"])"(?:[^\r\n"\\]|\\.)*"/,lookbehind:!0,greedy:!0,inside:{interpolation:{pattern:/((?:^|[^\\])(?:\\{2})*)\$(?:\{[\s\S]*?\}|[a-zA-Z_]\w*|0x[a-fA-F0-9]{2})/,lookbehind:!0,inside:{number:/^\$0x[\s\S]{2}$/,variable:/^\$\w+$/,"interpolation-punctuation":{pattern:/^\$\{|\}$/,alias:"punctuation"},expression:{pattern:/[\s\S]+/,inside:null}}},string:/[\s\S]+/}},keyword:/\b(?:else|if)\b/,boolean:/\b(?:false|true)\b/,"builtin-function":{pattern:/\b(?:assert|defined|foreach|import|pool|print|template|tool|toolchain)(?=\s*\()/i,alias:"keyword"},function:/\b[a-z_]\w*(?=\s*\()/i,constant:/\b(?:current_cpu|current_os|current_toolchain|default_toolchain|host_cpu|host_os|root_build_dir|root_gen_dir|root_out_dir|target_cpu|target_gen_dir|target_os|target_out_dir)\b/,number:/-?\b\d+\b/,operator:/[-+!=<>]=?|&&|\|\|/,punctuation:/[(){}[\],.]/},e.languages.gn["string-literal"].inside.interpolation.inside.expression.inside=e.languages.gn,e.languages.gni=e.languages.gn}e.exports=n,n.displayName="gn",n.aliases=["gni"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26625.d5154eea.chunk.js b/ydb/core/viewer/monitoring/static/js/26625.d5154eea.chunk.js new file mode 100644 index 000000000000..0ee9896167e7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26625.d5154eea.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26625],{26625:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-au",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/26833.d6c6c578.chunk.js b/ydb/core/viewer/monitoring/static/js/26833.d6c6c578.chunk.js new file mode 100644 index 000000000000..e9c328ea7725 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/26833.d6c6c578.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[26833],{26833:function(e,_,i){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var i=_(e),n={name:"fr-ch",weekdays:"dimanche_lundi_mardi_mercredi_jeudi_vendredi_samedi".split("_"),months:"janvier_f\xe9vrier_mars_avril_mai_juin_juillet_ao\xfbt_septembre_octobre_novembre_d\xe9cembre".split("_"),weekStart:1,weekdaysShort:"dim._lun._mar._mer._jeu._ven._sam.".split("_"),monthsShort:"janv._f\xe9vr._mars_avr._mai_juin_juil._ao\xfbt_sept._oct._nov._d\xe9c.".split("_"),weekdaysMin:"di_lu_ma_me_je_ve_sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"dans %s",past:"il y a %s",s:"quelques secondes",m:"une minute",mm:"%d minutes",h:"une heure",hh:"%d heures",d:"un jour",dd:"%d jours",M:"un mois",MM:"%d mois",y:"un an",yy:"%d ans"}};return i.default.locale(n,null,!0),n}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/27148.5289994c.chunk.js b/ydb/core/viewer/monitoring/static/js/27148.5289994c.chunk.js new file mode 100644 index 000000000000..1d995f5255a5 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/27148.5289994c.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 27148.5289994c.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[27148],{27148:(e,n,o)=>{o.r(n),o.d(n,{conf:()=>t,language:()=>s});var t={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"`",close:"`",notIn:["string"]},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"`",close:"`"},{open:'"',close:'"'},{open:"'",close:"'"}]},s={defaultToken:"",tokenPostfix:".go",keywords:["break","case","chan","const","continue","default","defer","else","fallthrough","for","func","go","goto","if","import","interface","map","package","range","return","select","struct","switch","type","var","bool","true","false","uint8","uint16","uint32","uint64","int8","int16","int32","int64","float32","float64","complex64","complex128","byte","rune","uint","int","uintptr","string","nil"],operators:["+","-","*","/","%","&","|","^","<<",">>","&^","+=","-=","*=","/=","%=","&=","|=","^=","<<=",">>=","&^=","&&","||","<-","++","--","==","<",">","=","!","!=","<=",">=",":=","...","(",")","","]","{","}",",",";",".",":"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F]/,"number.hex"],[/0[0-7']*[0-7]/,"number.octal"],[/0[bB][0-1']*[0-1]/,"number.binary"],[/\d[\d']*/,"number"],[/\d/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/`/,"string","@rawstring"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\/\*/,"comment.doc.invalid"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],rawstring:[[/[^\`]/,"string"],[/`/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2742.d5c8fae8.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/27148.5289994c.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2742.d5c8fae8.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/27148.5289994c.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/2726.abc3a0c2.chunk.js b/ydb/core/viewer/monitoring/static/js/2726.abc3a0c2.chunk.js new file mode 100644 index 000000000000..829fea3284af --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/2726.abc3a0c2.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 2726.abc3a0c2.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1606,2726],{1606:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>d,language:()=>u});var o,r,i=n(80781),s=Object.defineProperty,a=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,g=Object.prototype.hasOwnProperty,l=(e,t,n,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let r of c(t))g.call(e,r)||r===n||s(e,r,{get:()=>t[r],enumerable:!(o=a(t,r))||o.enumerable});return e},p={};l(p,o=i,"default"),r&&l(r,o,"default");var d={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],onEnterRules:[{beforeText:/^\s*\/\*\*(?!\/)([^\*]|\*(?!\/))*$/,afterText:/^\s*\*\/$/,action:{indentAction:p.languages.IndentAction.IndentOutdent,appendText:" * "}},{beforeText:/^\s*\/\*\*(?!\/)([^\*]|\*(?!\/))*$/,action:{indentAction:p.languages.IndentAction.None,appendText:" * "}},{beforeText:/^(\t|(\ \ ))*\ \*(\ ([^\*]|\*(?!\/))*)?$/,action:{indentAction:p.languages.IndentAction.None,appendText:"* "}},{beforeText:/^(\t|(\ \ ))*\ \*\/\s*$/,action:{indentAction:p.languages.IndentAction.None,removeText:1}}],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"`",close:"`",notIn:["string","comment"]},{open:"/**",close:" */",notIn:["string"]}],folding:{markers:{start:new RegExp("^\\s*//\\s*#?region\\b"),end:new RegExp("^\\s*//\\s*#?endregion\\b")}}},u={defaultToken:"invalid",tokenPostfix:".ts",keywords:["abstract","any","as","asserts","bigint","boolean","break","case","catch","class","continue","const","constructor","debugger","declare","default","delete","do","else","enum","export","extends","false","finally","for","from","function","get","if","implements","import","in","infer","instanceof","interface","is","keyof","let","module","namespace","never","new","null","number","object","out","package","private","protected","public","override","readonly","require","global","return","satisfies","set","static","string","super","switch","symbol","this","throw","true","try","type","typeof","undefined","unique","unknown","var","void","while","with","yield","async","await","of"],operators:["<=",">=","==","!=","===","!==","=>","+","-","**","*","/","%","++","--","<<",">",">>>","&","|","^","!","~","&&","||","??","?",":","=","+=","-=","*=","**=","/=","%=","<<=",">>=",">>>=","&=","|=","^=","@"],symbols:/[=>](?!@symbols)/,"@brackets"],[/!(?=([^=]|$))/,"delimiter"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/(@digits)[eE]([\-+]?(@digits))?/,"number.float"],[/(@digits)\.(@digits)([eE][\-+]?(@digits))?/,"number.float"],[/0[xX](@hexdigits)n?/,"number.hex"],[/0[oO]?(@octaldigits)n?/,"number.octal"],[/0[bB](@binarydigits)n?/,"number.binary"],[/(@digits)n?/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string_double"],[/'/,"string","@string_single"],[/`/,"string","@string_backtick"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@jsdoc"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],jsdoc:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],regexp:[[/(\{)(\d+(?:,\d*)?)(\})/,["regexp.escape.control","regexp.escape.control","regexp.escape.control"]],[/(\[)(\^?)(?=(?:[^\]\\\/]|\\.)+)/,["regexp.escape.control",{token:"regexp.escape.control",next:"@regexrange"}]],[/(\()(\?:|\?=|\?!)/,["regexp.escape.control","regexp.escape.control"]],[/[()]/,"regexp.escape.control"],[/@regexpctl/,"regexp.escape.control"],[/[^\\\/]/,"regexp"],[/@regexpesc/,"regexp.escape"],[/\\\./,"regexp.invalid"],[/(\/)([dgimsuy]*)/,[{token:"regexp",bracket:"@close",next:"@pop"},"keyword.other"]]],regexrange:[[/-/,"regexp.escape.control"],[/\^/,"regexp.invalid"],[/@regexpesc/,"regexp.escape"],[/[^\]]/,"regexp"],[/\]/,{token:"regexp.escape.control",next:"@pop",bracket:"@close"}]],string_double:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],string_single:[[/[^\\']+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/'/,"string","@pop"]],string_backtick:[[/\$\{/,{token:"delimiter.bracket",next:"@bracketCounting"}],[/[^\\`$]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/`/,"string","@pop"]],bracketCounting:[[/\{/,"delimiter.bracket","@bracketCounting"],[/\}/,"delimiter.bracket","@pop"],{include:"common"}]}}},2726:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>r,language:()=>i});var o=n(1606),r=o.conf,i={defaultToken:"invalid",tokenPostfix:".js",keywords:["break","case","catch","class","continue","const","constructor","debugger","default","delete","do","else","export","extends","false","finally","for","from","function","get","if","import","in","instanceof","let","new","null","return","set","static","super","switch","symbol","this","throw","true","try","typeof","undefined","var","void","while","with","yield","async","await","of"],typeKeywords:[],operators:o.language.operators,symbols:o.language.symbols,escapes:o.language.escapes,digits:o.language.digits,octaldigits:o.language.octaldigits,binarydigits:o.language.binarydigits,hexdigits:o.language.hexdigits,regexpctl:o.language.regexpctl,regexpesc:o.language.regexpesc,tokenizer:o.language.tokenizer}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2854.48cc58dc.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/2726.abc3a0c2.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/2854.48cc58dc.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/2726.abc3a0c2.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/2726.e753cb7c.chunk.js b/ydb/core/viewer/monitoring/static/js/2726.e753cb7c.chunk.js deleted file mode 100644 index f371c25b8092..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2726.e753cb7c.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2726.e753cb7c.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[1606,2726],{2726:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>r,language:()=>i});var o=n(1606),r=o.conf,i={defaultToken:"invalid",tokenPostfix:".js",keywords:["break","case","catch","class","continue","const","constructor","debugger","default","delete","do","else","export","extends","false","finally","for","from","function","get","if","import","in","instanceof","let","new","null","return","set","static","super","switch","symbol","this","throw","true","try","typeof","undefined","var","void","while","with","yield","async","await","of"],typeKeywords:[],operators:o.language.operators,symbols:o.language.symbols,escapes:o.language.escapes,digits:o.language.digits,octaldigits:o.language.octaldigits,binarydigits:o.language.binarydigits,hexdigits:o.language.hexdigits,regexpctl:o.language.regexpctl,regexpesc:o.language.regexpesc,tokenizer:o.language.tokenizer}},1606:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>d,language:()=>u});var o,r,i=n(80781),s=Object.defineProperty,a=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,g=Object.prototype.hasOwnProperty,l=(e,t,n,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let r of c(t))g.call(e,r)||r===n||s(e,r,{get:()=>t[r],enumerable:!(o=a(t,r))||o.enumerable});return e},p={};l(p,o=i,"default"),r&&l(r,o,"default");var d={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],onEnterRules:[{beforeText:/^\s*\/\*\*(?!\/)([^\*]|\*(?!\/))*$/,afterText:/^\s*\*\/$/,action:{indentAction:p.languages.IndentAction.IndentOutdent,appendText:" * "}},{beforeText:/^\s*\/\*\*(?!\/)([^\*]|\*(?!\/))*$/,action:{indentAction:p.languages.IndentAction.None,appendText:" * "}},{beforeText:/^(\t|(\ \ ))*\ \*(\ ([^\*]|\*(?!\/))*)?$/,action:{indentAction:p.languages.IndentAction.None,appendText:"* "}},{beforeText:/^(\t|(\ \ ))*\ \*\/\s*$/,action:{indentAction:p.languages.IndentAction.None,removeText:1}}],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"`",close:"`",notIn:["string","comment"]},{open:"/**",close:" */",notIn:["string"]}],folding:{markers:{start:new RegExp("^\\s*//\\s*#?region\\b"),end:new RegExp("^\\s*//\\s*#?endregion\\b")}}},u={defaultToken:"invalid",tokenPostfix:".ts",keywords:["abstract","any","as","asserts","bigint","boolean","break","case","catch","class","continue","const","constructor","debugger","declare","default","delete","do","else","enum","export","extends","false","finally","for","from","function","get","if","implements","import","in","infer","instanceof","interface","is","keyof","let","module","namespace","never","new","null","number","object","out","package","private","protected","public","override","readonly","require","global","return","satisfies","set","static","string","super","switch","symbol","this","throw","true","try","type","typeof","undefined","unique","unknown","var","void","while","with","yield","async","await","of"],operators:["<=",">=","==","!=","===","!==","=>","+","-","**","*","/","%","++","--","<<",">",">>>","&","|","^","!","~","&&","||","??","?",":","=","+=","-=","*=","**=","/=","%=","<<=",">>=",">>>=","&=","|=","^=","@"],symbols:/[=>](?!@symbols)/,"@brackets"],[/!(?=([^=]|$))/,"delimiter"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/(@digits)[eE]([\-+]?(@digits))?/,"number.float"],[/(@digits)\.(@digits)([eE][\-+]?(@digits))?/,"number.float"],[/0[xX](@hexdigits)n?/,"number.hex"],[/0[oO]?(@octaldigits)n?/,"number.octal"],[/0[bB](@binarydigits)n?/,"number.binary"],[/(@digits)n?/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string_double"],[/'/,"string","@string_single"],[/`/,"string","@string_backtick"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@jsdoc"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],jsdoc:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],regexp:[[/(\{)(\d+(?:,\d*)?)(\})/,["regexp.escape.control","regexp.escape.control","regexp.escape.control"]],[/(\[)(\^?)(?=(?:[^\]\\\/]|\\.)+)/,["regexp.escape.control",{token:"regexp.escape.control",next:"@regexrange"}]],[/(\()(\?:|\?=|\?!)/,["regexp.escape.control","regexp.escape.control"]],[/[()]/,"regexp.escape.control"],[/@regexpctl/,"regexp.escape.control"],[/[^\\\/]/,"regexp"],[/@regexpesc/,"regexp.escape"],[/\\\./,"regexp.invalid"],[/(\/)([dgimsuy]*)/,[{token:"regexp",bracket:"@close",next:"@pop"},"keyword.other"]]],regexrange:[[/-/,"regexp.escape.control"],[/\^/,"regexp.invalid"],[/@regexpesc/,"regexp.escape"],[/[^\]]/,"regexp"],[/\]/,{token:"regexp.escape.control",next:"@pop",bracket:"@close"}]],string_double:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],string_single:[[/[^\\']+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/'/,"string","@pop"]],string_backtick:[[/\$\{/,{token:"delimiter.bracket",next:"@bracketCounting"}],[/[^\\`$]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/`/,"string","@pop"]],bracketCounting:[[/\{/,"delimiter.bracket","@bracketCounting"],[/\}/,"delimiter.bracket","@pop"],{include:"common"}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2742.d5c8fae8.chunk.js b/ydb/core/viewer/monitoring/static/js/2742.d5c8fae8.chunk.js deleted file mode 100644 index ee6a21caf179..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2742.d5c8fae8.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2742.d5c8fae8.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2742],{32742:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>r});var i={wordPattern:/(#?-?\d*\.\d\w*%?)|((::|[@#.!:])?[\w-?]+%?)|::|[@#.!:]/g,comments:{blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]},{open:"'",close:"'",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*\\/\\*\\s*#region\\b\\s*(.*?)\\s*\\*\\/"),end:new RegExp("^\\s*\\/\\*\\s*#endregion\\b.*\\*\\/")}}},r={defaultToken:"",tokenPostfix:".css",ws:"[ \t\n\r\f]*",identifier:"-?-?([a-zA-Z]|(\\\\(([0-9a-fA-F]{1,6}\\s?)|[^[0-9a-fA-F])))([\\w\\-]|(\\\\(([0-9a-fA-F]{1,6}\\s?)|[^[0-9a-fA-F])))*",brackets:[{open:"{",close:"}",token:"delimiter.bracket"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],tokenizer:{root:[{include:"@selector"}],selector:[{include:"@comments"},{include:"@import"},{include:"@strings"},["[@](keyframes|-webkit-keyframes|-moz-keyframes|-o-keyframes)",{token:"keyword",next:"@keyframedeclaration"}],["[@](page|content|font-face|-moz-document)",{token:"keyword"}],["[@](charset|namespace)",{token:"keyword",next:"@declarationbody"}],["(url-prefix)(\\()",["attribute.value",{token:"delimiter.parenthesis",next:"@urldeclaration"}]],["(url)(\\()",["attribute.value",{token:"delimiter.parenthesis",next:"@urldeclaration"}]],{include:"@selectorname"},["[\\*]","tag"],["[>\\+,]","delimiter"],["\\[",{token:"delimiter.bracket",next:"@selectorattribute"}],["{",{token:"delimiter.bracket",next:"@selectorbody"}]],selectorbody:[{include:"@comments"},["[*_]?@identifier@ws:(?=(\\s|\\d|[^{;}]*[;}]))","attribute.name","@rulevalue"],["}",{token:"delimiter.bracket",next:"@pop"}]],selectorname:[["(\\.|#(?=[^{])|%|(@identifier)|:)+","tag"]],selectorattribute:[{include:"@term"},["]",{token:"delimiter.bracket",next:"@pop"}]],term:[{include:"@comments"},["(url-prefix)(\\()",["attribute.value",{token:"delimiter.parenthesis",next:"@urldeclaration"}]],["(url)(\\()",["attribute.value",{token:"delimiter.parenthesis",next:"@urldeclaration"}]],{include:"@functioninvocation"},{include:"@numbers"},{include:"@name"},{include:"@strings"},["([<>=\\+\\-\\*\\/\\^\\|\\~,])","delimiter"],[",","delimiter"]],rulevalue:[{include:"@comments"},{include:"@strings"},{include:"@term"},["!important","keyword"],[";","delimiter","@pop"],["(?=})",{token:"",next:"@pop"}]],warndebug:[["[@](warn|debug)",{token:"keyword",next:"@declarationbody"}]],import:[["[@](import)",{token:"keyword",next:"@declarationbody"}]],urldeclaration:[{include:"@strings"},["[^)\r\n]+","string"],["\\)",{token:"delimiter.parenthesis",next:"@pop"}]],parenthizedterm:[{include:"@term"},["\\)",{token:"delimiter.parenthesis",next:"@pop"}]],declarationbody:[{include:"@term"},[";","delimiter","@pop"],["(?=})",{token:"",next:"@pop"}]],comments:[["\\/\\*","comment","@comment"],["\\/\\/+.*","comment"]],comment:[["\\*\\/","comment","@pop"],[/[^*/]+/,"comment"],[/./,"comment"]],name:[["@identifier","attribute.value"]],numbers:[["-?(\\d*\\.)?\\d+([eE][\\-+]?\\d+)?",{token:"attribute.value.number",next:"@units"}],["#[0-9a-fA-F_]+(?!\\w)","attribute.value.hex"]],units:[["(em|ex|ch|rem|fr|vmin|vmax|vw|vh|vm|cm|mm|in|px|pt|pc|deg|grad|rad|turn|s|ms|Hz|kHz|%)?","attribute.value.unit","@pop"]],keyframedeclaration:[["@identifier","attribute.value"],["{",{token:"delimiter.bracket",switchTo:"@keyframebody"}]],keyframebody:[{include:"@term"},["{",{token:"delimiter.bracket",next:"@selectorbody"}],["}",{token:"delimiter.bracket",next:"@pop"}]],functioninvocation:[["@identifier\\(",{token:"attribute.value",next:"@functionarguments"}]],functionarguments:[["\\$@identifier@ws:","attribute.name"],["[,]","delimiter"],{include:"@term"},["\\)",{token:"attribute.value",next:"@pop"}]],strings:[['~?"',{token:"string",next:"@stringenddoublequote"}],["~?'",{token:"string",next:"@stringendquote"}]],stringenddoublequote:[["\\\\.","string"],['"',{token:"string",next:"@pop"}],[/[^\\"]+/,"string"],[".","string"]],stringendquote:[["\\\\.","string"],["'",{token:"string",next:"@pop"}],[/[^\\']+/,"string"],[".","string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2775.9105769d.chunk.js b/ydb/core/viewer/monitoring/static/js/2775.9105769d.chunk.js deleted file mode 100644 index d958f69ab1de..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2775.9105769d.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2775],{72775:function(a,_,e){a.exports=function(a){"use strict";function _(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var e=_(a),t={name:"tr",weekdays:"Pazar_Pazartesi_Sal\u0131_\xc7ar\u015famba_Per\u015fembe_Cuma_Cumartesi".split("_"),weekdaysShort:"Paz_Pts_Sal_\xc7ar_Per_Cum_Cts".split("_"),weekdaysMin:"Pz_Pt_Sa_\xc7a_Pe_Cu_Ct".split("_"),months:"Ocak_\u015eubat_Mart_Nisan_May\u0131s_Haziran_Temmuz_A\u011fustos_Eyl\xfcl_Ekim_Kas\u0131m_Aral\u0131k".split("_"),monthsShort:"Oca_\u015eub_Mar_Nis_May_Haz_Tem_A\u011fu_Eyl_Eki_Kas_Ara".split("_"),weekStart:1,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s sonra",past:"%s \xf6nce",s:"birka\xe7 saniye",m:"bir dakika",mm:"%d dakika",h:"bir saat",hh:"%d saat",d:"bir g\xfcn",dd:"%d g\xfcn",M:"bir ay",MM:"%d ay",y:"bir y\u0131l",yy:"%d y\u0131l"},ordinal:function(a){return a+"."}};return e.default.locale(t,null,!0),t}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2776.0f5e87f5.chunk.js b/ydb/core/viewer/monitoring/static/js/2776.0f5e87f5.chunk.js deleted file mode 100644 index 7248311c90cc..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2776.0f5e87f5.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2776],{12776:function(e,u,a){e.exports=function(e){"use strict";function u(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=u(e),_={name:"tet",weekdays:"Domingu_Segunda_Tersa_Kuarta_Kinta_Sesta_Sabadu".split("_"),months:"Janeiru_Fevereiru_Marsu_Abril_Maiu_Ju\xf1u_Jullu_Agustu_Setembru_Outubru_Novembru_Dezembru".split("_"),weekStart:1,weekdaysShort:"Dom_Seg_Ters_Kua_Kint_Sest_Sab".split("_"),monthsShort:"Jan_Fev_Mar_Abr_Mai_Jun_Jul_Ago_Set_Out_Nov_Dez".split("_"),weekdaysMin:"Do_Seg_Te_Ku_Ki_Ses_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"iha %s",past:"%s liuba",s:"minutu balun",m:"minutu ida",mm:"minutu %d",h:"oras ida",hh:"oras %d",d:"loron ida",dd:"loron %d",M:"fulan ida",MM:"fulan %d",y:"tinan ida",yy:"tinan %d"}};return a.default.locale(_,null,!0),_}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/27950.acee5eec.chunk.js b/ydb/core/viewer/monitoring/static/js/27950.acee5eec.chunk.js new file mode 100644 index 000000000000..76f060c9ef4b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/27950.acee5eec.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[27950],{18989:e=>{function t(e){e.languages.tcl={comment:{pattern:/(^|[^\\])#.*/,lookbehind:!0},string:{pattern:/"(?:[^"\\\r\n]|\\(?:\r\n|[\s\S]))*"/,greedy:!0},variable:[{pattern:/(\$)(?:::)?(?:[a-zA-Z0-9]+::)*\w+/,lookbehind:!0},{pattern:/(\$)\{[^}]+\}/,lookbehind:!0},{pattern:/(^[\t ]*set[ \t]+)(?:::)?(?:[a-zA-Z0-9]+::)*\w+/m,lookbehind:!0}],function:{pattern:/(^[\t ]*proc[ \t]+)\S+/m,lookbehind:!0},builtin:[{pattern:/(^[\t ]*)(?:break|class|continue|error|eval|exit|for|foreach|if|proc|return|switch|while)\b/m,lookbehind:!0},/\b(?:else|elseif)\b/],scope:{pattern:/(^[\t ]*)(?:global|upvar|variable)\b/m,lookbehind:!0,alias:"constant"},keyword:{pattern:/(^[\t ]*|\[)(?:Safe_Base|Tcl|after|append|apply|array|auto_(?:execok|import|load|mkindex|qualify|reset)|automkindex_old|bgerror|binary|catch|cd|chan|clock|close|concat|dde|dict|encoding|eof|exec|expr|fblocked|fconfigure|fcopy|file(?:event|name)?|flush|gets|glob|history|http|incr|info|interp|join|lappend|lassign|lindex|linsert|list|llength|load|lrange|lrepeat|lreplace|lreverse|lsearch|lset|lsort|math(?:func|op)|memory|msgcat|namespace|open|package|parray|pid|pkg_mkIndex|platform|puts|pwd|re_syntax|read|refchan|regexp|registry|regsub|rename|scan|seek|set|socket|source|split|string|subst|tcl(?:_endOfWord|_findLibrary|startOf(?:Next|Previous)Word|test|vars|wordBreak(?:After|Before))|tell|time|tm|trace|unknown|unload|unset|update|uplevel|vwait)\b/m,lookbehind:!0},operator:/!=?|\*\*?|==|&&?|\|\|?|<[=<]?|>[=>]?|[-+~\/%?^]|\b(?:eq|in|ne|ni)\b/,punctuation:/[{}()\[\]]/}}e.exports=t,t.displayName="tcl",t.aliases=[]},27950:(e,t,a)=>{a.d(t,{default:()=>n});var r=a(18989);const n=a.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/28125.0776827a.chunk.js b/ydb/core/viewer/monitoring/static/js/28125.0776827a.chunk.js new file mode 100644 index 000000000000..cff5873f476b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/28125.0776827a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[28125],{19560:e=>{function r(e){e.languages.io={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?(?:\*\/|$)|\/\/.*|#.*)/,lookbehind:!0,greedy:!0},"triple-quoted-string":{pattern:/"""(?:\\[\s\S]|(?!""")[^\\])*"""/,greedy:!0,alias:"string"},string:{pattern:/"(?:\\.|[^\\\r\n"])*"/,greedy:!0},keyword:/\b(?:activate|activeCoroCount|asString|block|break|call|catch|clone|collectGarbage|compileString|continue|do|doFile|doMessage|doString|else|elseif|exit|for|foreach|forward|getEnvironmentVariable|getSlot|hasSlot|if|ifFalse|ifNil|ifNilEval|ifTrue|isActive|isNil|isResumable|list|message|method|parent|pass|pause|perform|performWithArgList|print|println|proto|raise|raiseResumable|removeSlot|resend|resume|schedulerSleepSeconds|self|sender|setSchedulerSleepSeconds|setSlot|shallowCopy|slotNames|super|system|then|thisBlock|thisContext|try|type|uniqueId|updateSlot|wait|while|write|yield)\b/,builtin:/\b(?:Array|AudioDevice|AudioMixer|BigNum|Block|Box|Buffer|CFunction|CGI|Color|Curses|DBM|DNSResolver|DOConnection|DOProxy|DOServer|Date|Directory|Duration|DynLib|Error|Exception|FFT|File|Fnmatch|Font|Future|GL|GLE|GLScissor|GLU|GLUCylinder|GLUQuadric|GLUSphere|GLUT|Host|Image|Importer|LinkList|List|Lobby|Locals|MD5|MP3Decoder|MP3Encoder|Map|Message|Movie|Notification|Number|Object|OpenGL|Point|Protos|Random|Regex|SGML|SGMLElement|SGMLParser|SQLite|Sequence|Server|ShowMessage|SleepyCat|SleepyCatCursor|Socket|SocketManager|Sound|Soup|Store|String|Tree|UDPSender|UPDReceiver|URL|User|Warning|WeakLink)\b/,boolean:/\b(?:false|nil|true)\b/,number:/\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e-?\d+)?/i,operator:/[=!*/%+\-^&|]=|>>?=?|<{t.d(r,{default:()=>i});var o=t(19560);const i=t.n(o)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/28256.20804e43.chunk.js b/ydb/core/viewer/monitoring/static/js/28256.20804e43.chunk.js new file mode 100644 index 000000000000..b175562803dd --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/28256.20804e43.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[28256],{28256:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),n={name:"ar-ly",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a\u0648_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648_\u0623\u063a\u0633\u0637\u0633_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),weekStart:6,weekdaysShort:"\u0623\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0623\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a\u0648_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648_\u0623\u063a\u0633\u0637\u0633_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},meridiem:function(_){return _>12?"\u0645":"\u0635"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"D/\u200fM/\u200fYYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"}};return t.default.locale(n,null,!0),n}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/2854.48cc58dc.chunk.js b/ydb/core/viewer/monitoring/static/js/2854.48cc58dc.chunk.js deleted file mode 100644 index fb38ee3e1950..000000000000 --- a/ydb/core/viewer/monitoring/static/js/2854.48cc58dc.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 2854.48cc58dc.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[2854],{32854:(e,o,n)=>{n.r(o),n.d(o,{conf:()=>s,language:()=>t});var s={comments:{blockComment:["/*","*/"],lineComment:"//"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string"]},{open:"[",close:"]",notIn:["string"]},{open:"(",close:")",notIn:["string"]},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"<",close:">"}]},t={defaultToken:"",tokenPostfix:".flow",keywords:["import","require","export","forbid","native","if","else","cast","unsafe","switch","default"],types:["io","mutable","bool","int","double","string","flow","void","ref","true","false","with"],operators:["=",">","<","<=",">=","==","!","!=",":=","::=","&&","||","+","-","*","/","@","&","%",":","->","\\","$","??","^"],symbols:/[@$=>](?!@symbols)/,"delimiter"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/((0(x|X)[0-9a-fA-F]*)|(([0-9]+\.?[0-9]*)|(\.[0-9]+))((e|E)(\+|-)?[0-9]+)?)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/28868.3c0ecf71.chunk.js b/ydb/core/viewer/monitoring/static/js/28868.3c0ecf71.chunk.js new file mode 100644 index 000000000000..bf50d4927028 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/28868.3c0ecf71.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[28868],{28868:(e,b,d)=>{d.r(b)}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/290.b4f1e118.chunk.js b/ydb/core/viewer/monitoring/static/js/290.b4f1e118.chunk.js deleted file mode 100644 index e95f4cdf6b99..000000000000 --- a/ydb/core/viewer/monitoring/static/js/290.b4f1e118.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[290],{90290:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"en-gb",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},ordinal:function(e){var a=["th","st","nd","rd"],_=e%100;return"["+e+(a[(_-20)%10]||a[_]||a[0])+"]"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/29006.cfe15e90.chunk.js b/ydb/core/viewer/monitoring/static/js/29006.cfe15e90.chunk.js new file mode 100644 index 000000000000..7e157fb17119 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/29006.cfe15e90.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[29006,94695],{2748:()=>{},5890:(e,t,a)=>{var n={"./simpleWorker":51929,"./simpleWorker.js":51929,"monaco-editor/esm/vs/base/common/worker/simpleWorker":51929,"monaco-editor/esm/vs/base/common/worker/simpleWorker.js":51929};function s(e){return Promise.resolve().then((()=>{if(!a.o(n,e)){var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}return a(n[e])}))}s.keys=()=>Object.keys(n),s.id=5890,e.exports=s},9204:(e,t,a)=>{var n={"./editorBaseApi":[73848],"./editorBaseApi.js":[73848],"./editorSimpleWorker":[16545],"./editorSimpleWorker.js":[16545],"./editorWorker":[10920],"./editorWorker.js":[10920],"./editorWorkerHost":[80718],"./editorWorkerHost.js":[80718],"./findSectionHeaders":[56691],"./findSectionHeaders.js":[56691],"./getIconClasses":[53068],"./getIconClasses.js":[53068],"./languageFeatureDebounce":[32500],"./languageFeatureDebounce.js":[32500],"./languageFeatures":[56942],"./languageFeatures.js":[56942],"./languageFeaturesService":[76007],"./languageFeaturesService.js":[76007],"./languageService":[17890],"./languageService.js":[17890],"./languagesAssociations":[99908],"./languagesAssociations.js":[99908],"./languagesRegistry":[69259],"./languagesRegistry.js":[69259],"./markerDecorations":[37550],"./markerDecorations.js":[37550],"./markerDecorationsService":[30707],"./markerDecorationsService.js":[30707],"./model":[23750],"./model.js":[23750],"./modelService":[16363],"./modelService.js":[16363],"./resolverService":[18938],"./resolverService.js":[18938],"./semanticTokensDto":[98232],"./semanticTokensDto.js":[98232],"./semanticTokensProviderStyling":[45538],"./semanticTokensProviderStyling.js":[45538],"./semanticTokensStyling":[74243],"./semanticTokensStyling.js":[74243],"./semanticTokensStylingService":[27004],"./semanticTokensStylingService.js":[27004],"./textModelSync/textModelSync.impl":[47443],"./textModelSync/textModelSync.impl.js":[47443],"./textModelSync/textModelSync.protocol":[28868,28868],"./textModelSync/textModelSync.protocol.js":[28868,28868],"./textResourceConfiguration":[90360],"./textResourceConfiguration.js":[90360],"./treeSitterParserService":[44432],"./treeSitterParserService.js":[44432],"./treeViewsDnd":[36723],"./treeViewsDnd.js":[36723],"./treeViewsDndService":[29100],"./treeViewsDndService.js":[29100],"./unicodeTextModelHighlighter":[74855],"./unicodeTextModelHighlighter.js":[74855],"monaco-editor/esm/vs/editor/common/services/editorBaseApi":[73848],"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":[73848],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":[16545],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":[16545],"monaco-editor/esm/vs/editor/common/services/editorWorker":[10920],"monaco-editor/esm/vs/editor/common/services/editorWorker.js":[10920],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":[80718],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":[80718],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":[56691],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":[56691],"monaco-editor/esm/vs/editor/common/services/getIconClasses":[53068],"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":[53068],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":[32500],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":[32500],"monaco-editor/esm/vs/editor/common/services/languageFeatures":[56942],"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":[56942],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":[76007],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":[76007],"monaco-editor/esm/vs/editor/common/services/languageService":[17890],"monaco-editor/esm/vs/editor/common/services/languageService.js":[17890],"monaco-editor/esm/vs/editor/common/services/languagesAssociations":[99908],"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":[99908],"monaco-editor/esm/vs/editor/common/services/languagesRegistry":[69259],"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":[69259],"monaco-editor/esm/vs/editor/common/services/markerDecorations":[37550],"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":[37550],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":[30707],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":[30707],"monaco-editor/esm/vs/editor/common/services/model":[23750],"monaco-editor/esm/vs/editor/common/services/model.js":[23750],"monaco-editor/esm/vs/editor/common/services/modelService":[16363],"monaco-editor/esm/vs/editor/common/services/modelService.js":[16363],"monaco-editor/esm/vs/editor/common/services/resolverService":[18938],"monaco-editor/esm/vs/editor/common/services/resolverService.js":[18938],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":[98232],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":[98232],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":[45538],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":[45538],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":[74243],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":[74243],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":[27004],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":[27004],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":[47443],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":[47443],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":[28868,28868],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":[28868,28868],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":[90360],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":[90360],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":[44432],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":[44432],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":[36723],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":[36723],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":[29100],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":[29100],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":[74855],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":[74855]};function s(e){if(!a.o(n,e))return Promise.resolve().then((()=>{var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}));var t=n[e],s=t[0];return Promise.all(t.slice(1).map(a.e)).then((()=>a(s)))}s.keys=()=>Object.keys(n),s.id=9204,e.exports=s},29096:(e,t,a)=>{"use strict";a.r(t),a.d(t,{Tenant:()=>Xx});var n=a(59284),s=a(61750),r=a(80987),i=a(64689),o=a(98167),l=a(61283),c=a(77506),d=a(60712);const u=(0,c.cn)("kv-split"),m=[0,100],p=[50,50];const h=function(e){const[t,a]=n.useState(),s=t=>{const{defaultSizePaneKey:a}=e;localStorage.setItem(a,t.join(","))};return n.useEffect((()=>{const{collapsedSizes:t,triggerCollapse:n}=e;if(n){const e=t||m;s(e),a(e)}}),[e.triggerCollapse]),n.useEffect((()=>{const{triggerExpand:t,defaultSizes:n}=e,r=n||p;t&&(s(r),a(r))}),[e.triggerExpand]),(0,d.jsx)(n.Fragment,{children:(0,d.jsx)(l.A,{direction:e.direction||"horizontal",sizes:t||(()=>{var t;const{defaultSizePaneKey:a,defaultSizes:n=p,initialSizes:s}=e;if(s)return s;return(null===(t=localStorage.getItem(a))||void 0===t?void 0:t.split(",").map(Number))||n})(),minSize:e.minSize||[0,0],onDrag:t=>{const{onSplitDragAdditional:a}=e;a&&a(),s(t)},className:u(null,e.direction||"horizontal"),gutterSize:8,onDragStart:()=>{const{onSplitStartDragAdditional:t}=e;t&&t(),a(void 0)},expandToMin:!0,children:e.children})})};var v=a(40174),g=a(21334);const y=g.F.injectEndpoints({endpoints:e=>({getOverview:e.query({queryFn:async({path:e,database:t,timeout:a},{signal:n})=>{try{return{data:await window.api.viewer.getDescribe({path:e,database:t,timeout:a},{signal:n})}}catch(s){return{error:s}}},serializeQueryArgs:({queryArgs:e})=>{const{database:t,path:a}=e;return{database:t,path:a}},keepUnusedDataFor:0,providesTags:["All","SchemaTree"]})})});var x=a(29078),f=a(76086),b=a(90182),j=a(81288),T=a(22680),S=a(52531),w=a(23871),N=a(52905),E=a(90053);const C=(0,c.cn)("ydb-drawer"),P=n.createContext({containerWidth:0,setContainerWidth:()=>{}}),I=({children:e,className:t})=>{const[a,s]=n.useState(0),r=n.useRef(null);n.useEffect((()=>{if(!r.current)return;const e=()=>{r.current&&s(r.current.clientWidth)};e();const t=new ResizeObserver(e);return t.observe(r.current),()=>{r.current&&t.disconnect()}}),[]);const i=n.useMemo((()=>({containerWidth:a,setContainerWidth:s})),[a]);return(0,d.jsx)(P.Provider,{value:i,children:(0,d.jsx)("div",{ref:r,className:C("drawer-container",t),children:e})})};var D=a(67028),_=a(18517),A=a(24555),R=a(74321),k=a(44508),O=a(52248),M=a(90565),L=a(49818),q=a(56839),z=a(61758),F=a.n(z),U=a(92459),Q=a(58351);const $=(0,c.cn)("heatmap"),B={width:0,height:0},H=10,W=e=>{const[t,a]=n.useState(B),{tablets:s}=e,r=n.useRef(null),i=n.useRef(null);n.useEffect((()=>{const e=r.current,a=e.getContext("2d");a.clearRect(0,0,e.offsetWidth,e.offsetHeight),s.map(function(e){return(a,n)=>{const{columnsCount:s}=t,r=n%s*12,i=12*Math.floor(n/s);e.fillStyle=a.color||"grey",e.fillRect(r,i,H,H)}}(a))})),n.useLayoutEffect((()=>{const e=i.current;if(e){const t=e.offsetWidth-15,n=Math.floor(t/12),r=Math.ceil(s.length/n);a({width:t,height:12*r,columnsCount:n,rowsCount:r})}}),[]);const o=()=>{let e=r.current,t=0;for(;e;)t+=e.offsetTop,e=e.offsetParent;return t},l=()=>{let e=r.current,t=0;for(;e;)t+=e.offsetLeft,e=e.offsetParent;return t},c=(e,a)=>{const{columnsCount:n}=t,s=Math.floor(e/12);return n*Math.floor(a/12)+s},u=F()(((t,a)=>{const n=new CustomEvent("scroll");window.dispatchEvent(n);const r=e.parentRef.current,i=t-l()+r.scrollLeft,d=a-o()+r.scrollTop,u=c(i,d),m=s[u];if(m){const n={name:m.currentMetric,value:m.formattedValue};e.showTooltip(void 0,m,"tablet",n,{left:t-20,top:a-20})}else e.hideTooltip()}),20);return(0,d.jsx)("div",{ref:i,className:$("canvas-container"),onMouseLeave:()=>{setTimeout((()=>{e.hideTooltip()}),40)},children:(0,d.jsx)("canvas",{ref:r,width:t.width,height:t.height,onClick:t=>{const a=e.parentRef.current,n=t.clientX-l()+a.scrollLeft,r=t.clientY-o()+a.scrollTop,i=c(n,r),d=s[i];d&&window.open((e=>{const{TabletId:t}=e,a=window.location.hostname,n=(0,U.DM)(t);return`https://${[a,Q.P8,n].map((e=>e.startsWith("/")?e.slice(1):e)).filter(Boolean).join("/")}`})(d),"_blank")},onMouseMove:e=>u(e.clientX,e.clientY)})})},G={r:255,g:4,b:0},V={r:255,g:219,b:77},J={r:59,g:201,b:53},K={CPU:{min:0,max:1e6},Network:{min:0,max:1e9},Storage:{min:0,max:2e9},DataSize:{min:0,max:2e9},RowCount:{min:0},IndexSize:{min:0}},Y=e=>{const t=e.toString(16);return 1===t.length?`0${t}`:t},Z=(e,t,a)=>{if(1===e)return[t];if(2===e)return[t,a];const n=(t.r-a.r)/(e-1),s=(t.g-a.g)/(e-1),r=(t.b-a.b)/(e-1),i=[];for(let o=0;o(({r:e,g:t,b:a})=>`#${Y(e)}${Y(t)}${Y(a)}`)(e)))},X=e=>{const t=Math.floor(e/2),a=t+1;return[...Z(e%2===0?t:t+1,J,V),...Z(a,V,G).slice(1)]},ee=(e,t)=>{const a=new Set,n=K[e]||{};t.forEach((t=>{var n;a.add(Number(null===(n=t.metrics)||void 0===n?void 0:n[e]))})),Number.isInteger(n.min)&&a.add(n.min),Number.isInteger(n.max)&&a.add(n.max);const s=Array.from(a.values()).sort(((e,t)=>e-t));return{min:s[0],max:s[s.length-1]}},te=(0,c.cn)("histogram"),ae=e=>{const t=n.useRef(),{data:a={},maxCount:s}=e,{count:r,leftBound:i,rightBound:o,color:l}=a,c=r/s*100;return(0,d.jsx)("div",{ref:t,className:te("item"),style:{backgroundColor:l,height:`${c}%`},onMouseEnter:()=>{const a=t.current;e.showTooltip(a,{count:r,leftBound:i,rightBound:o},"histogram")},onMouseLeave:e.hideTooltip})},ne=e=>{const{tablets:t,currentMetric:a}=e,{min:n,max:s}=ee(a,t),r=X(50),i=(s-n)/50,o=r.map(((e,t)=>({color:e,count:0,leftBound:(0,q.ZV)(n+t*i),rightBound:(0,q.ZV)(n+(t+1)*i)})));let l=0;t.forEach((e=>{var t,n;const s=a&&Number(null===(t=e.metrics)||void 0===t?void 0:t[a]),r=Math.floor(s/i),c=(null===(n=o[r])||void 0===n?void 0:n.count)+1;c>l&&(l=c),o[r]={...o[r],count:c}}));return(0,d.jsx)("div",{className:te(),children:(0,d.jsxs)("div",{className:te("chart"),children:[Boolean(s)&&o.map(((t,a)=>(0,d.jsx)(ae,{data:t,maxCount:l,showTooltip:e.showTooltip,hideTooltip:e.hideTooltip},a))),(0,d.jsx)("div",{className:te("x-min"),children:(0,q.ZV)(n)}),(0,d.jsx)("div",{className:te("x-max"),children:(0,q.ZV)(s)}),(0,d.jsx)("div",{className:te("y-min"),children:"0"}),(0,d.jsx)("div",{className:te("y-max"),children:(0,q.ZV)(l)})]})})},se=(0,c.cn)("heatmap"),re=X(500),ie=({path:e,database:t})=>{const a=(0,b.YQ)(),s=n.createRef(),[r]=(0,b.Nt)(),{currentData:i,isFetching:o,error:l}=M.f1.useGetHeatmapTabletsInfoQuery({path:e,database:t},{pollingInterval:r}),c=o&&void 0===i,{tablets:u=[],metrics:m}=i||{},{sort:p,heatmap:h,currentMetric:v}=(0,b.N4)((e=>e.heatmap)),g=(...e)=>{a((0,L.DK)(...e))},y=()=>{a((0,L.w7)())},x=e=>{a((0,M.nd)({currentMetric:e[0]}))},f=()=>{a((0,M.nd)({sort:!p}))},j=()=>{a((0,M.nd)({heatmap:!h}))},T=()=>{const{min:e,max:t}=ee(v,u),a=u.map((a=>{var n;const s=v&&Number(null===(n=a.metrics)||void 0===n?void 0:n[v]),r=((e,t,a)=>0===a?0:Math.round((e-t)/(a-t)*499))(s,e,t),i=re[r];return{...a,color:i,value:s,formattedValue:(0,q.ZV)(s),currentMetric:v}})),n=p?a.sort(((e,t)=>Number(t.value)-Number(e.value))):a;return(0,d.jsx)("div",{ref:s,className:se("items"),children:(0,d.jsx)(W,{tablets:n,parentRef:s,showTooltip:g,hideTooltip:y})})};return c?(0,d.jsx)(O.a,{}):(()=>{const{min:e,max:t}=ee(v,u);let a;return l&&!i||(a=h?T():(0,d.jsx)(ne,{tablets:u,currentMetric:v,showTooltip:g,hideTooltip:y})),(0,d.jsxs)("div",{className:se(),children:[(0,d.jsxs)("div",{className:se("filters"),children:[(0,d.jsx)(A.l,{className:se("heatmap-select"),value:v?[v]:[],options:m,onUpdate:x,width:200}),(0,d.jsx)("div",{className:se("sort-checkbox"),children:(0,d.jsx)(R.S,{onUpdate:f,checked:p,children:"Sort"})}),(0,d.jsx)("div",{className:se("histogram-checkbox"),children:(0,d.jsx)(R.S,{onUpdate:j,checked:h,children:"Heatmap"})}),(0,d.jsxs)("div",{className:se("limits"),children:[(0,d.jsxs)("div",{className:se("limits-block"),children:[(0,d.jsx)("div",{className:se("limits-title"),children:"min:"}),(0,d.jsx)("div",{className:se("limits-value"),children:Number.isInteger(e)?(0,q.ZV)(e):"\u2014"})]}),(0,d.jsxs)("div",{className:se("limits-block"),children:[(0,d.jsx)("div",{className:se("limits-title"),children:"max:"}),(0,d.jsx)("div",{className:se("limits-value"),children:Number.isInteger(t)?(0,q.ZV)(t):"\u2014"})]}),(0,d.jsxs)("div",{className:se("limits-block"),children:[(0,d.jsx)("div",{className:se("limits-title"),children:"count:"}),(0,d.jsx)("div",{className:se("limits-value"),children:(0,q.ZV)(u.length)})]})]})]}),l?(0,d.jsx)(k.o,{error:l}):null,a]})})()};var oe=a(11363),le=a(59109),ce=a(17594),de=a(69326);const ue=g.F.injectEndpoints({endpoints:e=>({getOperationList:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.operation.getOperationList(e,{signal:t})}}catch(a){return{error:a}}},providesTags:["All"]}),cancelOperation:e.mutation({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.operation.cancelOperation(e,{signal:t})}}catch(a){return{error:a}}}}),forgetOperation:e.mutation({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.operation.forgetOperation(e,{signal:t})}}catch(a){return{error:a}}}})}),overrideExisting:"throw"});var me=a(28539),pe=a(95963),he=a(48372);const ve=JSON.parse('{"label_operations":"Operations","title_empty":"No operations data","pleaceholder_search":"Search operations","placeholder_kind":"Select operation kind","kind_ssBackgrounds":"SS/Backgrounds","kind_export_s3":"Export/S3","kind_export_yt":"Export/YT","kind_import_s3":"Import/S3","kind_buildIndex":"Build Index","column_operationId":"Operation ID","column_status":"Status","column_createdBy":"Created By","column_createTime":"Create Time","column_endTime":"End Time","column_duration":"Duration","label_duration-ongoing":"{{value}} (ongoing)","header_cancel":"Cancel operation","header_forget":"Forget operation","text_cancel":"The operation will be cancelled. Do you want to proceed?","text_forget":"The operation will be forgotten. Do you want to proceed?","text_forgotten":"The operation {{id}} has been forgotten","text_cancelled":"The operation {{id}} has been cancelled"}'),ge=(0,he.g4)("ydb-operations",{en:ve}),ye="id",xe="status",fe="created_by",be="create_time",je="end_time",Te="duration",Se={[ye]:ge("column_operationId"),[xe]:ge("column_status"),[fe]:ge("column_createdBy"),[be]:ge("column_createTime"),[je]:ge("column_endTime"),[Te]:ge("column_duration")},we=[{value:"export/s3",content:ge("kind_export_s3")},{value:"export/yt",content:ge("kind_export_yt")},{value:"import/s3",content:ge("kind_import_s3")},{value:"ss/backgrounds",content:ge("kind_ssBackgrounds")},{value:"buildindex",content:ge("kind_buildIndex")}],Ne=(0,c.cn)("operations");function Ee({kind:e,searchValue:t,entitiesCountCurrent:a,entitiesCountTotal:s,entitiesLoading:r,handleKindChange:i,handleSearchChange:o}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(pe.v,{value:t,onChange:o,placeholder:ge("pleaceholder_search"),className:Ne("search")}),(0,d.jsx)(A.l,{value:[e],width:150,options:we,onUpdate:e=>i(e[0])}),(0,d.jsx)(me.T,{label:ge("label_operations"),loading:r,total:s,current:a})]})}var Ce=a(14750),Pe=a(58272),Ie=a(45345),De=a(98089),_e=a(87184),Ae=a(60865),Re=a(99991),ke=a(22983),Oe=a(71661);let Me=function(e){return e.STATUS_CODE_UNSPECIFIED="STATUS_CODE_UNSPECIFIED",e.SUCCESS="SUCCESS",e.BAD_REQUEST="BAD_REQUEST",e.UNAUTHORIZED="UNAUTHORIZED",e.INTERNAL_ERROR="INTERNAL_ERROR",e.ABORTED="ABORTED",e.UNAVAILABLE="UNAVAILABLE",e.OVERLOADED="OVERLOADED",e.SCHEME_ERROR="SCHEME_ERROR",e.GENERIC_ERROR="GENERIC_ERROR",e.TIMEOUT="TIMEOUT",e.BAD_SESSION="BAD_SESSION",e.PRECONDITION_FAILED="PRECONDITION_FAILED",e.ALREADY_EXISTS="ALREADY_EXISTS",e.NOT_FOUND="NOT_FOUND",e.SESSION_EXPIRED="SESSION_EXPIRED",e.CANCELLED="CANCELLED",e.UNDETERMINED="UNDETERMINED",e.UNSUPPORTED="UNSUPPORTED",e.SESSION_BUSY="SESSION_BUSY",e.EXTERNAL_ERROR="EXTERNAL_ERROR",e}({});var Le=a(59625);const qe=function({name:e,title:t,type:a,content:n,autoHiding:s,className:r}){return Le.X.add({name:null!==e&&void 0!==e?e:"Request succeeded",title:null!==t&&void 0!==t?t:"Request succeeded",theme:"error"===a?"danger":"success",content:n,isClosable:!0,autoHiding:null!==s&&void 0!==s?s:"success"===a&&5e3,className:r})};var ze=a(73891);function Fe({database:e,refreshTable:t}){return[{name:ye,header:Se[ye],width:340,render:({row:e})=>e.id?(0,d.jsx)(Oe.s,{placement:["top","bottom"],content:e.id,children:e.id}):f.Pd},{name:xe,header:Se[xe],render:({row:e})=>e.status?(0,d.jsx)(De.E,{color:e.status===Me.SUCCESS?"positive":"danger",children:e.status}):f.Pd},{name:fe,header:Se[fe],render:({row:e})=>e.created_by?e.created_by:f.Pd},{name:be,header:Se[be],render:({row:e})=>e.create_time?(0,q.r6)((0,ze.ee)(e.create_time)):f.Pd,sortAccessor:e=>e.create_time?(0,ze.ee)(e.create_time):0},{name:je,header:Se[je],render:({row:e})=>e.end_time?(0,q.r6)((0,ze.ee)(e.end_time)):f.Pd,sortAccessor:e=>e.end_time?(0,ze.ee)(e.end_time):Number.MAX_SAFE_INTEGER},{name:Te,header:Se[Te],render:({row:e})=>{let t=0;if(!e.create_time)return f.Pd;const a=(0,ze.ee)(e.create_time);if(e.end_time){t=(0,ze.ee)(e.end_time)-a}else t=Date.now()-a;const n=t>f.Jg*f.KF?(0,Ce.p0)(t).format("hh:mm:ss"):(0,Ce.p0)(t).format("mm:ss");return e.end_time?n:ge("label_duration-ongoing",{value:n})},sortAccessor:e=>{if(!e.create_time)return 0;const t=(0,ze.ee)(e.create_time);if(e.end_time){return(0,ze.ee)(e.end_time)-t}return Date.now()-t}},{name:"Actions",sortable:!1,resizeable:!1,header:"",render:({row:a})=>(0,d.jsx)(Ue,{operation:a,database:e,refreshTable:t})}]}function Ue({operation:e,database:t,refreshTable:a}){const[n,{isLoading:s}]=ue.useCancelOperationMutation(),[r,{isLoading:i}]=ue.useForgetOperationMutation(),o=e.id;return o?(0,d.jsxs)(_e.s,{gap:"2",children:[(0,d.jsx)(Ae.m,{title:ge("header_forget"),placement:["left","auto"],children:(0,d.jsx)("div",{children:(0,d.jsx)(ke.B,{buttonView:"outlined",dialogHeader:ge("header_forget"),dialogText:ge("text_forget"),onConfirmAction:()=>r({id:o,database:t}).unwrap().then((()=>{qe({name:"Forgotten",title:ge("text_forgotten",{id:o}),type:"success"}),a()})),buttonDisabled:s,children:(0,d.jsx)(Re.I,{data:Pe.A})})})}),(0,d.jsx)(Ae.m,{title:ge("header_cancel"),placement:["right","auto"],children:(0,d.jsx)("div",{children:(0,d.jsx)(ke.B,{buttonView:"outlined",dialogHeader:ge("header_cancel"),dialogText:ge("text_cancel"),onConfirmAction:()=>n({id:o,database:t}).unwrap().then((()=>{qe({name:"Cancelled",title:ge("text_cancelled",{id:o}),type:"success"}),a()})),buttonDisabled:i,children:(0,d.jsx)(Re.I,{data:Ie.A})})})})]}):null}var Qe=a(370);const $e=Qe.z.enum(["ss/backgrounds","export/s3","export/yt","import/s3","buildindex"]).catch("buildindex");function Be({database:e}){var t;const[a]=(0,b.Nt)(),{kind:s,searchValue:i,pageSize:o,pageToken:l,handleKindChange:c,handleSearchChange:u}=function(){var e,t,a;const[n,s]=(0,r.useQueryParams)({kind:r.StringParam,search:r.StringParam,pageSize:r.NumberParam,pageToken:r.StringParam});return{kind:$e.parse(n.kind),searchValue:null!==(e=n.search)&&void 0!==e?e:"",pageSize:null!==(t=n.pageSize)&&void 0!==t?t:void 0,pageToken:null!==(a=n.pageToken)&&void 0!==a?a:void 0,handleKindChange:e=>{s({kind:e},"replaceIn")},handleSearchChange:e=>{s({search:e||void 0},"replaceIn")},handlePageSizeChange:e=>{s({pageSize:e},"replaceIn")},handlePageTokenChange:e=>{s({pageToken:e},"replaceIn")}}}(),{data:m,isLoading:p,error:h,refetch:v}=ue.useGetOperationListQuery({database:e,kind:s,page_size:o,page_token:l},{pollingInterval:a}),g=n.useMemo((()=>null!==m&&void 0!==m&&m.operations?m.operations.filter((e=>{var t;return null===(t=e.id)||void 0===t?void 0:t.toLowerCase().includes(i.toLowerCase())})):[]),[null===m||void 0===m?void 0:m.operations,i]);return(0,j.Pq)(h)?(0,d.jsx)(le.O,{position:"left"}):(0,d.jsxs)(de.L,{children:[(0,d.jsx)(de.L.Controls,{children:(0,d.jsx)(Ee,{kind:s,searchValue:i,entitiesCountCurrent:g.length,entitiesCountTotal:null===m||void 0===m||null===(t=m.operations)||void 0===t?void 0:t.length,entitiesLoading:p,handleKindChange:c,handleSearchChange:u})}),h?(0,d.jsx)(k.o,{error:h}):null,(0,d.jsx)(de.L.Table,{loading:p,className:Ne("table"),children:m?(0,d.jsx)(ce.l,{columns:Fe({database:e,refreshTable:v}),columnsWidthLSKey:"selectedOperationColumns",data:g,emptyDataMessage:ge("title_empty")}):null})]})}var He=a(47199),We=a(71635),Ge=a(19228),Ve=a(11822);function Je(e){return`SELECT * FROM \`${e}\` LIMIT 0`}const Ke=g.F.injectEndpoints({endpoints:e=>({getViewSchema:e.query({queryFn:async({database:e,path:t,timeout:a})=>{try{var n,s;const r=await window.api.viewer.sendQuery({query:Je(t),database:e,action:"execute-scan",timeout:a},{withRetries:!0});return(0,Ve.We)(r)?{error:r}:{data:(null===r||void 0===r||null===(n=r.result)||void 0===n||null===(s=n[0])||void 0===s?void 0:s.columns)||[]}}catch(r){return{error:r}}},serializeQueryArgs:({queryArgs:e})=>{const{database:t,path:a}=e;return{database:t,path:a}},providesTags:["All","SchemaTree"]})}),overrideExisting:"throw"});let Ye=function(e){return e.EPathTypeInvalid="EPathTypeInvalid",e.EPathTypeDir="EPathTypeDir",e.EPathTypeTable="EPathTypeTable",e.EPathTypePersQueueGroup="EPathTypePersQueueGroup",e.EPathTypeSubDomain="EPathTypeSubDomain",e.EPathTypeTableIndex="EPathTypeTableIndex",e.EPathTypeExtSubDomain="EPathTypeExtSubDomain",e.EPathTypeColumnStore="EPathTypeColumnStore",e.EPathTypeColumnTable="EPathTypeColumnTable",e.EPathTypeCdcStream="EPathTypeCdcStream",e.EPathTypeExternalDataSource="EPathTypeExternalDataSource",e.EPathTypeExternalTable="EPathTypeExternalTable",e.EPathTypeView="EPathTypeView",e.EPathTypeReplication="EPathTypeReplication",e.EPathTypeTransfer="EPathTypeTransfer",e.EPathTypeResourcePool="EPathTypeResourcePool",e}({}),Ze=function(e){return e.EPathSubTypeEmpty="EPathSubTypeEmpty",e.EPathSubTypeSyncIndexImplTable="EPathSubTypeSyncIndexImplTable",e.EPathSubTypeAsyncIndexImplTable="EPathSubTypeAsyncIndexImplTable",e.EPathSubTypeStreamImpl="EPathSubTypeStreamImpl",e}({});let Xe=function(e){return e.ColumnCodecPlain="ColumnCodecPlain",e.ColumnCodecLZ4="ColumnCodecLZ4",e.ColumnCodecZSTD="ColumnCodecZSTD",e}({});let et=function(e){return e.METERING_MODE_RESERVED_CAPACITY="METERING_MODE_RESERVED_CAPACITY",e.METERING_MODE_REQUEST_UNITS="METERING_MODE_REQUEST_UNITS",e}({});const tt={[Ze.EPathSubTypeSyncIndexImplTable]:"index_table",[Ze.EPathSubTypeAsyncIndexImplTable]:"index_table",[Ze.EPathSubTypeStreamImpl]:void 0,[Ze.EPathSubTypeEmpty]:void 0},at={[Ye.EPathTypeInvalid]:void 0,[Ye.EPathTypeSubDomain]:"database",[Ye.EPathTypeExtSubDomain]:"database",[Ye.EPathTypeDir]:"directory",[Ye.EPathTypeColumnStore]:"directory",[Ye.EPathTypeTable]:"table",[Ye.EPathTypeTableIndex]:"index",[Ye.EPathTypeColumnTable]:"column_table",[Ye.EPathTypeCdcStream]:"stream",[Ye.EPathTypePersQueueGroup]:"topic",[Ye.EPathTypeExternalDataSource]:"external_data_source",[Ye.EPathTypeExternalTable]:"external_table",[Ye.EPathTypeView]:"view",[Ye.EPathTypeReplication]:"async_replication",[Ye.EPathTypeTransfer]:"transfer",[Ye.EPathTypeResourcePool]:"resource_pool"},nt={table:Ye.EPathTypeTable,index:Ye.EPathTypeTableIndex,column_table:Ye.EPathTypeColumnTable,external_table:Ye.EPathTypeExternalTable,view:Ye.EPathTypeView},st=(e=Ye.EPathTypeDir,t,a="directory")=>t&&tt[t]||at[e]||a,rt={[Ze.EPathSubTypeSyncIndexImplTable]:"Secondary Index Table",[Ze.EPathSubTypeAsyncIndexImplTable]:"Secondary Index Table",[Ze.EPathSubTypeStreamImpl]:void 0,[Ze.EPathSubTypeEmpty]:void 0},it={[Ye.EPathTypeInvalid]:void 0,[Ye.EPathTypeSubDomain]:"Database",[Ye.EPathTypeExtSubDomain]:"Database",[Ye.EPathTypeDir]:"Directory",[Ye.EPathTypeTable]:"Table",[Ye.EPathTypeTableIndex]:"Secondary Index",[Ye.EPathTypeColumnStore]:"Tablestore",[Ye.EPathTypeColumnTable]:"Column-oriented table",[Ye.EPathTypeCdcStream]:"Changefeed",[Ye.EPathTypePersQueueGroup]:"Topic",[Ye.EPathTypeExternalDataSource]:"External Data Source",[Ye.EPathTypeExternalTable]:"External Table",[Ye.EPathTypeView]:"View",[Ye.EPathTypeReplication]:"Async Replication",[Ye.EPathTypeTransfer]:"Transfer",[Ye.EPathTypeResourcePool]:"Resource Pool"},ot={UnknownTenantType:"Database",Domain:"Cluster Root",Dedicated:"Dedicated Database",Shared:"Shared Database",Serverless:"Serverless Database"},lt={[Ye.EPathTypeTable]:!0,[Ye.EPathTypeColumnTable]:!0,[Ye.EPathTypeExternalTable]:!0,[Ye.EPathTypeView]:!0,[Ye.EPathTypeInvalid]:!1,[Ye.EPathTypeDir]:!1,[Ye.EPathTypeSubDomain]:!1,[Ye.EPathTypeTableIndex]:!1,[Ye.EPathTypeExtSubDomain]:!1,[Ye.EPathTypeColumnStore]:!1,[Ye.EPathTypeCdcStream]:!1,[Ye.EPathTypePersQueueGroup]:!1,[Ye.EPathTypeExternalDataSource]:!1,[Ye.EPathTypeReplication]:!1,[Ye.EPathTypeTransfer]:!1,[Ye.EPathTypeResourcePool]:!1},ct=e=>{var t;return null!==(t=e&<[e])&&void 0!==t&&t},dt={[Ze.EPathSubTypeSyncIndexImplTable]:!0,[Ze.EPathSubTypeAsyncIndexImplTable]:!0,[Ze.EPathSubTypeStreamImpl]:!1,[Ze.EPathSubTypeEmpty]:!1},ut=e=>{var t;return null!==(t=e&&dt[e])&&void 0!==t&&t},mt={[Ye.EPathTypeColumnStore]:!0,[Ye.EPathTypeColumnTable]:!0,[Ye.EPathTypeInvalid]:!1,[Ye.EPathTypeDir]:!1,[Ye.EPathTypeTable]:!1,[Ye.EPathTypeSubDomain]:!1,[Ye.EPathTypeTableIndex]:!1,[Ye.EPathTypeExtSubDomain]:!1,[Ye.EPathTypeCdcStream]:!1,[Ye.EPathTypePersQueueGroup]:!1,[Ye.EPathTypeExternalDataSource]:!1,[Ye.EPathTypeExternalTable]:!1,[Ye.EPathTypeView]:!1,[Ye.EPathTypeReplication]:!1,[Ye.EPathTypeTransfer]:!1,[Ye.EPathTypeResourcePool]:!1},pt=e=>{var t;return null!==(t=e&&mt[e])&&void 0!==t&&t},ht={[Ye.EPathTypeSubDomain]:!0,[Ye.EPathTypeExtSubDomain]:!0,[Ye.EPathTypeInvalid]:!1,[Ye.EPathTypeDir]:!1,[Ye.EPathTypeColumnStore]:!1,[Ye.EPathTypeColumnTable]:!1,[Ye.EPathTypeTable]:!1,[Ye.EPathTypeTableIndex]:!1,[Ye.EPathTypeCdcStream]:!1,[Ye.EPathTypePersQueueGroup]:!1,[Ye.EPathTypeExternalDataSource]:!1,[Ye.EPathTypeExternalTable]:!1,[Ye.EPathTypeView]:!1,[Ye.EPathTypeReplication]:!1,[Ye.EPathTypeTransfer]:!1,[Ye.EPathTypeResourcePool]:!1},vt=e=>{var t;return null!==(t=e&&ht[e])&&void 0!==t&&t},gt={[Ze.EPathSubTypeSyncIndexImplTable]:!0,[Ze.EPathSubTypeAsyncIndexImplTable]:!0,[Ze.EPathSubTypeStreamImpl]:!0,[Ze.EPathSubTypeEmpty]:!1},yt={[Ye.EPathTypeCdcStream]:!1,[Ye.EPathTypePersQueueGroup]:!0,[Ye.EPathTypeExternalDataSource]:!0,[Ye.EPathTypeExternalTable]:!0,[Ye.EPathTypeView]:!0,[Ye.EPathTypeResourcePool]:!0,[Ye.EPathTypeReplication]:!0,[Ye.EPathTypeTransfer]:!0,[Ye.EPathTypeInvalid]:!1,[Ye.EPathTypeColumnStore]:!1,[Ye.EPathTypeColumnTable]:!1,[Ye.EPathTypeDir]:!1,[Ye.EPathTypeTable]:!1,[Ye.EPathTypeSubDomain]:!1,[Ye.EPathTypeTableIndex]:!1,[Ye.EPathTypeExtSubDomain]:!1},xt=(e,t)=>{var a;return null!==(a=t&>[t]||e&&yt[e])&&void 0!==a&&a},ft=e=>e===Ye.EPathTypeExternalTable,bt=e=>e===Ye.EPathTypeTable,jt=e=>e===Ye.EPathTypeView;var Tt=a(47665),St=a(24543);const wt=JSON.parse('{"column-title.id":"Id","column-title.name":"Name","column-title.type":"Type","column-title.notNull":"NotNull","column-title.autoIncrement":"AutoIncrement","column-title.defaultValue":"Default","column-title.family":"Family","column-title.media":"Media","column-title.compression":"Compression","primary-key.title":"Primary key:","partitioning-key.title":"Partitioning key:"}'),Nt=(0,he.g4)("ydb-schema-viewer",{en:wt}),Et=(0,c.cn)("schema-viewer");const Ct=({tableData:e,extended:t,type:a})=>{const n="primary"===a?function(e){return e.filter((e=>Boolean(void 0!==e.keyColumnIndex&&-1!==e.keyColumnIndex&&e.name))).sort(((e,t)=>e.keyColumnIndex-t.keyColumnIndex)).map((e=>e.name))}(e):function(e){return e.filter((e=>Boolean(void 0!==e.partitioningColumnIndex&&-1!==e.partitioningColumnIndex&&e.name))).sort(((e,t)=>e.partitioningColumnIndex-t.partitioningColumnIndex)).map((e=>e.name))}(e),s=t?3:n.length,r=n.slice(0,s),i=n.slice(s);return n.length>0?(0,d.jsxs)("div",{className:Et("keys",{summary:!t,type:a}),children:[(0,d.jsx)("div",{className:Et("keys-header"),children:Nt("primary"===a?"primary-key.title":"partitioning-key.title")}),(0,d.jsxs)("div",{className:Et("keys-values"),children:[" "+r.join(", "),i.length?(0,d.jsx)(St.u,{className:Et("more-badge"),placement:["bottom"],hasArrow:!1,pinOnClick:!0,content:(0,d.jsx)("div",{className:Et("popup-content"),children:i.map((e=>(0,d.jsx)("div",{className:Et("popup-item"),children:e},e)))}),children:(0,d.jsx)(Tt.J,{className:Et("keys-label"),children:`+${i.length}`})}):null]})]}):null};var Pt=a(4557);function It({data:e,name:t,header:a,sortable:n}){const s="string"===typeof a?a.length:t.length;let r=n?s+2:s;if(e)for(const i of e){let e=0;if(i[t]&&(e=String(i[t]).length),r=Math.max(r,e),10*r+20>=600)return 600}return 10*r+20}var Dt=a(34671);const _t="name",At="type",Rt="notNull",kt="autoIncrement",Ot="defaultValue",Mt="familyName",Lt="prefferedPoolKind",qt="columnCodec",zt={name:"id",get header(){return Nt("column-title.id")},width:60,align:Pt.Ay.RIGHT,render:({row:e})=>{const t=(0,d.jsx)(Re.I,{className:Et("key-icon"),size:12,data:Dt.A});return(0,d.jsxs)("span",{className:Et("id-wrapper"),children:[e.id,void 0===e.keyColumnIndex||-1===e.keyColumnIndex?null:t]})}},Ft={name:_t,get header(){return Nt("column-title.name")},width:120,render:({row:e})=>e.name},Ut={name:At,get header(){return Nt("column-title.type")},width:100,render:({row:e})=>e.type},Qt={name:Rt,get header(){return Nt("column-title.notNull")},width:100,defaultOrder:Pt.Ay.DESCENDING,render:({row:e})=>{if(e.notNull)return"\u2713"}},$t={name:kt,get header(){return Nt("column-title.autoIncrement")},width:100,defaultOrder:Pt.Ay.DESCENDING,render:({row:e})=>{if(e.autoIncrement)return"\u2713"}},Bt={name:Ot,get header(){return Nt("column-title.defaultValue")},width:100,render:({row:e})=>String(e.defaultValue)},Ht={name:Mt,get header(){return Nt("column-title.family")},width:100,render:({row:e})=>e.familyName},Wt={name:Lt,get header(){return Nt("column-title.media")},width:100,render:({row:e})=>e.prefferedPoolKind},Gt={name:qt,get header(){return Nt("column-title.compression")},width:130,render:({row:e})=>e.columnCodec};function Vt(e,t){if(!t)return e;const a=t.slice(0,100);return e.map((e=>({...e,width:It({data:a,name:e.name,header:"string"===typeof e.header?e.header:void 0,sortable:e.sortable||void 0===e.sortable})})))}function Jt(e={}){const t=function(e){var t,a,n;return null!==(t=null===e||void 0===e||null===(a=e.PartitionConfig)||void 0===a||null===(n=a.ColumnFamilies)||void 0===n?void 0:n.reduce(((e,t)=>t.Id?{...e,[t.Id]:t}:e),{}))&&void 0!==t?t:{}}(e),{Columns:a,KeyColumnNames:n}=e,s=null===a||void 0===a?void 0:a.map((e=>{var a,s,r,i;const{Id:o,Name:l,NotNull:c,Type:d,Family:u,DefaultFromSequence:m,DefaultFromLiteral:p}=e,h=null!==(a=null===n||void 0===n?void 0:n.findIndex((e=>e===l)))&&void 0!==a?a:-1,v=u?t[u].Name:void 0,g=u?null===(s=t[u].StorageConfig)||void 0===s||null===(r=s.Data)||void 0===r?void 0:r.PreferredPoolKind:void 0,y=u?function(e){if(e)return e===Xe.ColumnCodecPlain?"None":e.replace("ColumnCodec","").toLocaleLowerCase()}(t[u].ColumnCodec):void 0;return{id:o,name:l,keyColumnIndex:h,type:d,notNull:c,autoIncrement:Boolean(m),defaultValue:null!==(i=Object.values((null===p||void 0===p?void 0:p.value)||{})[0])&&void 0!==i?i:"-",familyName:v,prefferedPoolKind:g,columnCodec:y}}));return null!==s&&void 0!==s?s:[]}function Kt(e,t){const{Table:a,ColumnTableDescription:n,ExternalTableDescription:s}=(null===t||void 0===t?void 0:t.PathDescription)||{};return bt(e)?Jt(a):pt(e)?function(e={}){const{Schema:t={},Sharding:a={}}=e,{Columns:n,KeyColumnNames:s}=t,{HashSharding:r={}}=a,{Columns:i=[]}=r,o=null===n||void 0===n?void 0:n.map((e=>{var t,a;const{Id:n,Name:r,Type:o,NotNull:l}=e,c=null!==(t=null===s||void 0===s?void 0:s.findIndex((e=>e===r)))&&void 0!==t?t:-1,d=null!==(a=null===i||void 0===i?void 0:i.findIndex((e=>e===r)))&&void 0!==a?a:-1;return{id:n,name:r,keyColumnIndex:c,partitioningColumnIndex:d,type:o,notNull:l}}));return[...(null===o||void 0===o?void 0:o.filter((e=>-1!==e.keyColumnIndex)))||[],...(null===o||void 0===o?void 0:o.filter((e=>-1===e.keyColumnIndex)))||[]]}(n):ft(e)?function(e={}){const{Columns:t}=e;return(null===t||void 0===t?void 0:t.map((e=>{const{Id:t,Name:a,Type:n,NotNull:s}=e;return{id:t,name:a,type:n,notNull:s}})))||[]}(s):[]}function Yt(e){return(null===e||void 0===e?void 0:e.map((e=>{var t;return{type:null!==(t=e.type)&&void 0!==t&&t.endsWith("?")?e.type.slice(0,-1):e.type,name:e.name}})))||[]}const Zt=({type:e,path:t,tenantName:a,extended:s=!1})=>{const[r]=(0,b.Nt)(),i=s?r:void 0,{currentData:o,isFetching:l}=y.useGetOverviewQuery({path:t,database:a},{pollingInterval:i,skip:jt(e)}),{currentData:c,isFetching:u}=Ke.useGetViewSchemaQuery({path:t,database:a},{pollingInterval:i,skip:!jt(e)}),m=u&&void 0===c||l&&void 0===o,p=n.useMemo((()=>jt(e)?Yt(c):Kt(e,o)),[o,e,c]),h=n.useMemo((()=>p.some((e=>e.autoIncrement))),[p]),v=n.useMemo((()=>p.some((e=>e.defaultValue))),[p]),g=n.useMemo((()=>jt(e)?Vt([Ft,Ut],p):ft(e)||pt(e)?function(e){return Vt([zt,Ft,Ut,Qt],e)}(p):bt(e)?function(e,t,a,n){const s=[zt,Ft,Ut,Qt];return n&&s.push(Bt),t&&s.push(Ht,Wt,Gt),a&&s.push($t),Vt(s,e)}(p,s,h,v):[]),[e,s,h,v,p]);return m?(0,d.jsx)(Ge.Q,{}):(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)("div",{className:Et("keys-wrapper"),children:[(0,d.jsx)(Ct,{tableData:p,extended:s,type:"primary"}),(0,d.jsx)(Ct,{tableData:p,extended:s,type:"partitioning"})]}),(0,d.jsx)("div",{className:Et(),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:"schemaTableColumnsWidth",data:p,columns:g,settings:f.N3})})]})};var Xt=a(96589),ea=a(84375),ta=a(85589);const aa=JSON.parse('{"td-feature-flag":"Feature flag","td-default":"Default","td-current":"Current","enabled":"Enabled","disabled":"Disabled","flag-touched":"Flag is changed","search-placeholder":"Search by feature flag","search-empty":"Empty search result","no-data":"No data"}'),na=(0,he.g4)("ydb-diagnostics-configs",{en:aa}),sa=(0,c.cn)("ydb-diagnostics-configs"),ra=[{name:"Touched",header:"",render:({row:e})=>e.Current?(0,d.jsx)(ea.A,{content:na("flag-touched"),className:sa("icon-touched"),placement:"left",children:(0,d.jsx)(Re.I,{data:Xt.A})}):null,width:36,sortable:!1,resizeable:!1},{name:"Name",get header(){return na("td-feature-flag")},render:({row:e})=>e.Current?(0,d.jsx)("b",{children:e.Name}):e.Name,width:400,sortable:!0,sortAccessor:({Current:e,Name:t})=>Number(!e)+t.toLowerCase()},{name:"Default",get header(){return na("td-default")},render:({row:e})=>{switch(e.Default){case!0:return na("enabled");case!1:return na("disabled");default:return"-"}},width:100,sortable:!1,resizeable:!1},{name:"Current",get header(){return na("td-current")},render:({row:e})=>{var t;return(0,d.jsx)(ta.d,{disabled:!0,checked:(null!==(t=e.Current)&&void 0!==t?t:e.Default)||!1})},width:100,sortable:!1,resizeable:!1}],ia=({database:e})=>{const[t,a]=(0,r.useQueryParam)("search",r.StringParam),[n]=(0,b.Nt)(),{currentData:s=[],isLoading:i,error:o}=_.z6.useGetClusterConfigQuery({database:e},{pollingInterval:n}),l=null===t||void 0===t?void 0:t.toLocaleLowerCase(),c=l?s.filter((e=>e.Name.toLocaleLowerCase().includes(l))):s;return(0,d.jsxs)(de.L,{children:[(0,d.jsx)(de.L.Controls,{children:(0,d.jsx)(pe.v,{value:l,onChange:e=>{a(e||void 0,"replaceIn")},placeholder:na("search-placeholder")})}),(0,d.jsx)(de.L.Table,{loading:i,children:o?(0,d.jsx)(k.o,{error:o}):(0,d.jsx)(ce.l,{emptyDataMessage:na(l?"search-empty":"no-data"),columnsWidthLSKey:"featureFlagsColumnsWidth",columns:ra,data:c,settings:f.N3})})]})};var oa=a(23536),la=a.n(oa),ca=a(53850),da=a(46549);const ua=g.F.injectEndpoints({endpoints:e=>({getTopic:e.query({queryFn:async e=>{try{const t=await window.api.viewer.getTopic(e);return"object"!==typeof t?{error:{}}:{data:t}}catch(t){return{error:t}}},providesTags:["All"]}),getTopicData:e.query({queryFn:async e=>{try{return{data:await window.api.viewer.getTopicData({message_size_limit:100,...e})}}catch(t){return{error:t}}},keepUnusedDataFor:0})}),overrideExisting:"throw"}),ma=(0,ca.Mz)((e=>e),((e,t)=>t),((e,t)=>ua.endpoints.getTopic.select({path:e,database:t}))),pa=(0,ca.Mz)((e=>e),((e,t,a)=>ma(t,a)),((e,t)=>{var a;return null===(a=t(e).data)||void 0===a?void 0:a.topic_stats})),ha=(0,ca.Mz)((e=>e),((e,t,a)=>ma(t,a)),((e,t)=>{var a;return null===(a=t(e).data)||void 0===a?void 0:a.consumers})),va=(0,ca.Mz)(ha,(e=>null===e||void 0===e?void 0:e.map((e=>null===e||void 0===e?void 0:e.name)).filter((e=>void 0!==e)))),ga=(0,ca.Mz)(pa,(e=>{if(!e)return;const{store_size_bytes:t="0",min_last_write_time:a,max_write_time_lag:n,bytes_written:s}=e||{};return{storeSize:t,partitionsIdleTime:(0,ze.MC)(a),partitionsWriteLag:(0,ze.i6)(n),writeSpeed:(0,da.ey)(s)}})),ya=(0,ca.Mz)(ha,(e=>null===e||void 0===e?void 0:e.map((e=>{const{name:t,consumer_stats:a}=e||{},{min_partitions_last_read_time:n,max_read_time_lag:s,max_write_time_lag:r,bytes_read:i}=a||{};return{name:t,readSpeed:(0,da.ey)(i),writeLag:(0,ze.i6)(r),readLag:(0,ze.i6)(s),readIdleTime:(0,ze.MC)(n)}})))),xa=JSON.parse('{"averageSpeed":"Average speed","perMinute":"per minute","perHour":"per hour","perDay":"per day"}'),fa=JSON.parse('{"averageSpeed":"\u0421\u0440\u0435\u0434\u043d\u044f\u044f \u0441\u043a\u043e\u0440\u043e\u0441\u0442\u044c","perMinute":"\u0437\u0430 \u043c\u0438\u043d\u0443\u0442\u0443","perHour":"\u0437\u0430 \u0447\u0430\u0441","perDay":"\u0437\u0430 \u0434\u0435\u043d\u044c"}'),ba=(0,he.g4)("ydb-components-speed-multimeter",{ru:fa,en:xa}),ja=(0,c.cn)("speed-multimeter"),Ta=({data:e,speedSize:t="kb",withValue:a=!0,withPopover:s=!0})=>{const{perMinute:r=0,perHour:i=0,perDay:o=0}=e||{},l=[r,i,o],c=e=>(0,da.z3)({value:e,size:t,withSpeedLabel:!0}),u=[{value:c(r),label:ba("perMinute")},{value:c(i),label:ba("perHour")},{value:c(o),label:ba("perDay")}],[m,p]=n.useState(r),[h,v]=n.useState(a?0:void 0),[g,y]=n.useState(),x=(e,t)=>{p(e[t]),v(t),y(t)},f=e=>h===e,b=e=>g===e;return(0,d.jsx)("div",{className:ja(),children:(0,d.jsxs)("div",{className:ja("content"),children:[a&&(0,d.jsx)("div",{className:ja("displayed-value"),children:c(m)}),(0,d.jsx)(ea.A,{content:(0,d.jsxs)("div",{className:ja("popover-content"),children:[(0,d.jsx)("span",{className:ja("popover-header"),children:ba("averageSpeed")}),u.map(((e,t)=>{return(0,d.jsx)("span",{className:ja("popover-row",(a=f(t),a?{color:"primary"}:{color:"secondary"})),children:`${e.label}: ${e.value}`},t);var a}))]}),className:ja("popover-container"),placement:"bottom",disabled:!s,hasArrow:!0,size:"s",children:(0,d.jsx)("div",{className:ja("bars"),onMouseLeave:()=>{p(r),v(a?0:void 0),y(void 0)},children:(()=>{const e=Math.max(...l,0)||1;return l.map(((t,a)=>(0,d.jsx)("div",{className:ja("bar-container",{highlighted:b(a)}),onMouseEnter:x.bind(null,l,a),children:(0,d.jsx)("div",{className:ja("bar",{color:f(a)?"dark":"light"}),style:{width:100*t/e+"%"}})},a)))})()})})]})})},Sa=(0,c.cn)("ydb-diagnostics-consumers-topic-stats"),wa=({data:e})=>{const{writeSpeed:t,partitionsWriteLag:a,partitionsIdleTime:n}=e||{},s=[{label:"Write speed",value:(0,d.jsx)(Ta,{data:t})},{label:"Write lag",value:(0,q.lr)(a||0)},{label:"Write idle time",value:(0,q.lr)(n||0)}];return(0,d.jsx)("div",{className:Sa("wrapper"),children:s.map(((e,t)=>(0,d.jsxs)("div",{className:Sa("item"),children:[(0,d.jsx)("div",{className:Sa("label"),children:e.label}),(0,d.jsx)("div",{className:Sa("value"),children:e.value})]},t)))})};var Na=a(74309),Ea=a.n(Na),Ca=a(44294),Pa=a(54309),Ia=a(6170);const Da=({text:e,popoverContent:t,popoverClassName:a,className:n,contentClassName:s,buttonProps:r})=>(0,d.jsxs)("div",{className:n,children:[e,"\xa0",(0,d.jsx)(Ia.B,{className:a,buttonProps:r,content:t,contentClassName:s})]}),_a=70,Aa=54,Ra=268,ka="#ADE8F5",Oa="#f5be9d",Ma=({width:e,height:t,transform:a})=>(0,d.jsx)("path",{d:`M-${e/2} 0 c0 -${t}, ${e} -${t}, ${e} 0`,fill:"none",strokeDasharray:"4,6",stroke:"#28f",strokeWidth:"1.6",transform:a}),La=({width:e})=>(0,d.jsx)("path",{fill:"none",strokeWidth:"2",d:`M0 0 h${e} l-10 -5 m0 10 l10 -5`}),qa=()=>(0,d.jsxs)("g",{fill:"var(--g-color-text-primary)",fontSize:"12",children:[(0,d.jsx)("g",{transform:"translate(0, 27)",stroke:Oa,children:(0,d.jsx)(La,{width:203})}),(0,d.jsxs)("g",{transform:"translate(30, 0)",children:[(0,d.jsxs)("g",{transform:"translate(35, 27)",children:[(0,d.jsx)(Ma,{width:_a,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write lag"})})]}),(0,d.jsxs)("g",{transform:"translate(119, 27)",children:[(0,d.jsx)(Ma,{width:98,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write idle time"})})]})]}),(0,d.jsxs)("g",{transform:"translate(30, 0)",children:[(0,d.jsxs)("g",{transform:"translate(0, 27)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:Oa}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"create time"})})]}),(0,d.jsxs)("g",{transform:"translate(70, 27)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:Oa}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write time"})})]}),(0,d.jsx)("g",{transform:"translate(168, 27)",children:(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"now"})})})]})]}),za=()=>(0,d.jsxs)("g",{fill:"var(--g-color-text-primary)",fontSize:"12",children:[(0,d.jsx)("g",{transform:"translate(0, 27)",stroke:ka,children:(0,d.jsx)(La,{width:Ra})}),(0,d.jsxs)("g",{transform:"translate(30, 0)",children:[(0,d.jsxs)("g",{transform:"translate(105, 27)",children:[(0,d.jsx)(Ma,{width:_a,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"read lag"})})]}),(0,d.jsxs)("g",{transform:"translate(35, 27)",children:[(0,d.jsx)(Ma,{width:_a,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write lag"})})]}),(0,d.jsxs)("g",{transform:"translate(182, 27)",children:[(0,d.jsx)(Ma,{width:91,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"read idle time"})})]})]}),(0,d.jsxs)("g",{transform:"translate(30, 27)",children:[(0,d.jsxs)("g",{transform:"translate(0, 0)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:ka}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"create time"})})]}),(0,d.jsxs)("g",{transform:"translate(70, 0)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:ka}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write time"})})]}),(0,d.jsxs)("g",{transform:"translate(140, 0)",children:[(0,d.jsx)("use",{x:"-2",y:"-10",xlinkHref:"#check",stroke:ka}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"read time"})})]}),(0,d.jsx)("g",{transform:"translate(224, 0)",children:(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"now"})})})]})]}),Fa=({id:e,fill:t})=>(0,d.jsx)("pattern",{id:e,x:"0",y:"0",width:"8",height:"8",patternUnits:"userSpaceOnUse",children:(0,d.jsx)("path",{d:"M0 5L5 0H8L0 8V5M5 8L8 5V8Z",fill:t})}),Ua=()=>(0,d.jsxs)("svg",{className:"paint",xmlns:"http://www.w3.org/2000/svg",xmlnsXlink:"http://www.w3.org/1999/xlink",viewBox:"0 0 268 54",width:Ra,height:Aa,children:[(0,d.jsxs)("defs",{children:[(0,d.jsx)("g",{id:"check",children:(0,d.jsx)("path",{d:"M0 3 v14",strokeWidth:"2"})}),(0,d.jsx)(Fa,{id:"latest-read",fill:ka}),(0,d.jsx)(Fa,{id:"latest-write",fill:Oa})]}),(0,d.jsx)(qa,{})]}),Qa=()=>(0,d.jsxs)("svg",{className:"paint",xmlns:"http://www.w3.org/2000/svg",xmlnsXlink:"http://www.w3.org/1999/xlink",viewBox:"0 0 268 54",width:Ra,height:Aa,children:[(0,d.jsxs)("defs",{children:[(0,d.jsx)("g",{id:"check",children:(0,d.jsx)("path",{d:"M0 3 v14",strokeWidth:"2"})}),(0,d.jsx)(Fa,{id:"latest-read",fill:ka}),(0,d.jsx)(Fa,{id:"latest-write",fill:Oa})]}),(0,d.jsx)(za,{})]}),$a=(0,c.cn)("ydb-lag-popover-content"),Ba=({text:e,type:t})=>(0,d.jsxs)("div",{className:$a({type:t}),children:[(0,d.jsx)("div",{className:$a("text"),children:e}),(0,d.jsx)("div",{children:"read"===t?(0,d.jsx)(Qa,{}):(0,d.jsx)(Ua,{})})]}),Ha=JSON.parse('{"noConsumersMessage.topic":"This topic has no consumers","noConsumersMessage.stream":"This changefeed has no consumers","lagsPopover.readLags":"Read lags statistics, maximum among all consumer partitions (time format dd hh:mm:ss)","table.emptyDataMessage":"No consumers match the current search","controls.search":"Consumer"}'),Wa=JSON.parse('{"noConsumersMessage.topic":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0442\u043e\u043f\u0438\u043a\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","noConsumersMessage.stream":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0441\u0442\u0440\u0438\u043c\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","lagsPopover.readLags":"\u0421\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0430 \u043b\u0430\u0433\u043e\u0432 \u0447\u0442\u0435\u043d\u0438\u044f, \u043c\u0430\u043a\u0441\u0438\u043c\u0430\u043b\u044c\u043d\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0441\u0440\u0435\u0434\u0438 \u0432\u0441\u0435\u0445 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u044f (\u0444\u043e\u0440\u043c\u0430\u0442 \u0432\u0440\u0435\u043c\u0435\u043d\u0438 \u0434\u0434 \u0447\u0447:\u043c\u043c:\u0441\u0441)","table.emptyDataMessage":"\u041f\u043e \u0437\u0430\u0434\u0430\u043d\u043d\u043e\u043c\u0443 \u043f\u043e\u0438\u0441\u043a\u0443 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","controls.search":"Consumer"}'),Ga=(0,he.g4)("ydb-diagnostics-consumers",{ru:Wa,en:Ha}),Va="consumer",Ja="readSpeed",Ka="readLags",Ya={[Va]:"Consumer",[Ja]:"Read speed",[Ka]:"Read lags, duration"},Za="writeLag",Xa="readLag",en="readIdleTime",tn={[Za]:"write lag",[Xa]:"read lag",[en]:"read idle time"},an=(0,c.cn)("ydb-diagnostics-consumers-columns-header"),nn=()=>(0,d.jsx)(Da,{className:an("lags"),text:Ya[Ka],popoverContent:(0,d.jsx)(Ba,{text:Ga("lagsPopover.readLags"),type:"read"})}),sn=(0,c.cn)("ydb-diagnostics-consumers-columns"),rn=[{name:Va,header:Ya[Va],align:Pt.Ay.LEFT,render:({row:e})=>{if(!e.name)return"\u2013";const t=Ea().parse(location.search,{ignoreQueryPrefix:!0});return(0,d.jsx)(Ca.E,{to:(0,Pa.YL)({...t,[Pa.vh.diagnosticsTab]:S.iJ.partitions,selectedConsumer:e.name}),children:e.name})}},{name:Ja,header:Ya[Ja],align:Pt.Ay.RIGHT,resizeMinWidth:140,sortAccessor:e=>e.readSpeed.perMinute,render:({row:e})=>(0,d.jsx)(Ta,{data:e.readSpeed})},{name:Ka,header:(0,d.jsx)(nn,{}),className:sn("lags-header"),sub:[{name:Za,header:tn[Za],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.writeLag)},{name:Xa,header:tn[Xa],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.readLag)},{name:en,header:tn[en],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.readIdleTime)}]}],on=(0,c.cn)("ydb-diagnostics-consumers"),ln=({path:e,database:t,type:a})=>{const s=(e=>e===Ye.EPathTypeCdcStream)(a),[r,i]=n.useState(""),[o]=(0,b.Nt)(),{currentData:l,isFetching:c,error:u}=ua.useGetTopicQuery({path:e,database:t},{pollingInterval:o}),m=c&&void 0===l,p=(0,b.N4)((a=>ya(a,e,t))),h=(0,b.N4)((a=>ga(a,e,t))),v=n.useMemo((()=>{if(!p)return[];const e=new RegExp(la()(r),"i");return p.filter((t=>e.test(String(t.name))))}),[p,r]);return m?(0,d.jsx)(O.a,{size:"m"}):u||p&&p.length?(0,d.jsxs)("div",{className:on(),children:[(0,d.jsxs)("div",{className:on("controls"),children:[(0,d.jsx)(pe.v,{onChange:e=>{i(e)},placeholder:Ga("controls.search"),className:on("search"),value:r}),h&&(0,d.jsx)(wa,{data:h})]}),u?(0,d.jsx)(k.o,{error:u}):null,p?(0,d.jsx)("div",{className:on("table-wrapper"),children:(0,d.jsx)("div",{className:on("table-content"),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:"consumersColumnsWidth",wrapperClassName:on("table"),data:v,columns:rn,settings:f.N3,emptyDataMessage:Ga("table.emptyDataMessage")})})}):null]}):(0,d.jsx)("div",{children:Ga("noConsumersMessage."+(s?"stream":"topic"))})};var cn=a(96873),dn=a(84476),un=a(39439),mn=a.n(un);function pn({className:e,text:t,start:a,length:s,hasComa:r}){const i=r?(0,d.jsx)(n.Fragment,{children:",\xa0"}):null;if(s&&"number"===typeof a&&a>=0&&aTn(e)),[e])}function wn(e){return t=>vn("filtered",t,e)}var Nn=a(70983);function En(e){const{row:{level:t,open:a,close:s,key:r,value:i,hasDelimiter:o,path:l,collapsed:c,depth:u},settings:m,onToggleCollapse:p,matched:h,filter:v,showFullText:g,index:y}=e,x=n.useCallback((()=>{l&&p(l)}),[l,p]),f=n.useCallback((()=>{g(y)}),[g,y]);return(0,d.jsxs)("div",{className:vn("cell","unipika"),children:[kn(t),l&&(0,d.jsx)(gn,{collapsed:c,path:l,onToggle:x}),(0,d.jsx)(Cn,{text:r,settings:m,matched:null===h||void 0===h?void 0:h.keyMatch,filter:v}),a&&(0,d.jsx)(An,{type:a,settings:m}),void 0!==u&&(0,d.jsx)("span",{className:"unipika",children:xn("context_items-count",{count:u})}),void 0!==i&&(0,d.jsx)(Pn,{text:i,settings:m,matched:null===h||void 0===h?void 0:h.valueMatch,filter:v,showFullText:f,maxValueWidth:e.maxValueWidth}),c&&void 0===u&&(0,d.jsx)("span",{className:"unipika",children:"..."}),s&&(0,d.jsx)(An,{type:s,settings:m,close:!0}),o&&(0,d.jsx)(_n,{text:","})]})}function Cn(e){const t=function(e){if(null===e||void 0===e||!e.text)return null;return Dn(e,vn("key"))}(e);return t?(0,d.jsxs)(n.Fragment,{children:[t,(0,d.jsx)(_n,{text:": "})]}):null}function Pn(e){var t;return(0,d.jsx)(n.Fragment,{children:In(e,vn("value",{type:null===(t=e.text)||void 0===t?void 0:t.$type}))})}function In(e,t){var a;return"string"===(null===(a=e.text)||void 0===a?void 0:a.$type)?Dn(e,t):function(e,t){const{text:a,filter:n,settings:s,matched:r}=e;let i=null;if(r&&n){const e=bn.format(a,{...s,asHTML:!1});i=(0,d.jsx)(hn,{className:wn(t),text:e,starts:r,length:null===n||void 0===n?void 0:n.length})}else i=a?function(e,t=jn){const a=bn.formatValue(e,{...jn,...t},0);return(0,d.jsx)("span",{className:"unipika",dangerouslySetInnerHTML:{__html:a}})}(a,s):void 0;return i||null}(e,vn("value"))}function Dn(e,t){const{text:a,settings:n=jn,matched:s=[],filter:r,showFullText:i,maxValueWidth:o=1/0}=e,l=bn.format(a,{...n,maxStringSize:10,asHTML:!1}),c=l.length,u=l.substring(1,Math.min(c-1,o+1)),m=u.length=0;--d)if(u.length{e.stopPropagation()},children:[(0,d.jsx)(Fn.l.Header,{caption:xn("description_full-value")}),(0,d.jsx)(Fn.l.Divider,{}),(0,d.jsx)(Fn.l.Body,{children:(0,d.jsx)(_e.s,{direction:"column",gap:2,width:"70vw",maxHeight:"80vh",children:(0,d.jsx)("div",{className:vn("full-value"),children:(0,d.jsx)(hn,{className:wn(),starts:a,text:t,length:n})})})})]})}function Qn(e,t){const a={dst:[],levels:[],path:[],collapsedState:(null===t||void 0===t?void 0:t.collapsedState)||{},matchedPath:"",collapsedPath:""};$n(e,0,a);const n=function(e,t,a){if(!t)return{};const n=Object.assign({},null===a||void 0===a?void 0:a.settings,{asHTML:!1}),s={};for(let r=0;r=0&&i(t&&(e[t]=!0),e)),{})}function is(e,t,a,n){const s=Qn(e,{collapsedState:t,filter:a,caseSensitive:n});return Object.assign({},{flattenResult:s,matchedRows:Object.keys(s.searchIndex).map(Number)})}function os(e){const{value:t}=e;return function(e){return!("_error"in e)}(t)?(0,d.jsx)(ls,{...e,value:t}):t._error}function ls({tableSettings:e,value:t,unipikaSettings:a,search:s=!0,extraTools:r,collapsedInitially:i,maxValueWidth:o=100,toolbarClassName:l}){const[c,u]=(0,b.iK)(f.iD,!1),[m,p]=n.useState((()=>i?rs(t):{})),[h,v]=n.useState(""),[g,y]=n.useState((()=>is(t,m,h,c))),[x,j]=n.useState(-1),[T,S]=n.useState(),w=n.useRef(null),N=n.useRef(null),E=n.useMemo((()=>({...ss,dynamicInnerRef:w,...e})),[e]),C=({row:e,index:t})=>{const{flattenResult:{searchIndex:n}}=g;return(0,d.jsx)(En,{matched:n[t],row:e,settings:a,onToggleCollapse:P,filter:h,showFullText:L,index:t,maxValueWidth:o})},P=e=>{const t={...m};t[e]?delete t[e]:t[e]=!0,I({collapsedState:t})},I=(e,a)=>{const{collapsedState:n,matchIndex:s,filter:r,caseSensitive:i}=e;void 0!==n&&p(n),void 0!==s&&j(s),void 0!==r&&v(r);y(is(t,null!==n&&void 0!==n?n:m,null!==r&&void 0!==r?r:h,null!==i&&void 0!==i?i:c)),null===a||void 0===a||a()},D=()=>{I({collapsedState:{}},(()=>{R(null,0)}))},_=()=>{const e=rs(t);I({collapsedState:e})},A=e=>{I({filter:e,matchIndex:0},(()=>{R(null,0)}))},R=(e,t=1)=>{var a,n;const{matchedRows:s}=g;if(!s.length)return;let r=(x+t)%s.length;r<0&&(r=s.length+r),r!==x&&j(r),null===(a=w.current)||void 0===a||a.scrollTo(s[r]-6),null===(n=N.current)||void 0===n||n.focus()},k=()=>{R(null,-1)},O=e=>{"Enter"===e.key&&(e.shiftKey||e.ctrlKey?k():R(null))},M=()=>{const e=!c;u(e),I({caseSensitive:e})},L=e=>{const{flattenResult:{searchIndex:t,data:a}}=g;S({value:a[e].value,searchInfo:t[e]})},q=()=>{S(void 0)};return(0,d.jsxs)("div",{className:vn(),children:[(0,d.jsxs)(_e.s,{gap:2,wrap:"nowrap",className:vn("toolbar",l),children:[(0,d.jsxs)(_e.s,{gap:1,wrap:"nowrap",children:[(0,d.jsx)(Ae.m,{title:xn("action_expand-all"),children:(0,d.jsx)(dn.$,{onClick:D,view:"flat-secondary",children:(0,d.jsx)(Re.I,{data:as.A})})}),(0,d.jsx)(Ae.m,{title:xn("action_collapse-all"),children:(0,d.jsx)(dn.$,{onClick:_,view:"flat-secondary",children:(0,d.jsx)(Re.I,{data:ns.A})})})]}),s&&(0,d.jsx)(zn,{onUpdate:A,matchIndex:x,matchedRows:g.matchedRows,value:h,ref:N,onKeyDown:O,onNextMatch:R,onPrevMatch:k,caseSensitive:c,onUpdateCaseSensitive:M}),(0,d.jsx)("span",{className:vn("extra-tools"),children:r})]}),(()=>{const e=[{name:"content",render:C,header:null}],{flattenResult:{data:t}}=g;return(0,d.jsx)("div",{className:vn("content"),children:(0,d.jsx)(Pt.Ay,{columns:e,data:t,theme:"yson",settings:E,rowClassName:()=>vn("row")})})})(),(()=>{const{value:e,searchInfo:t}=null!==T&&void 0!==T?T:{},n=bn.format(e,{...a,asHTML:!1});return e&&(0,d.jsx)(Un,{onClose:q,starts:(null===t||void 0===t?void 0:t.valueMatch)||[],text:n.substring(1,n.length-1),length:h.length})})()]})}const cs=(0,c.cn)("ydb-describe"),ds=({path:e,database:t})=>{const[a]=(0,b.Nt)(),{currentData:n,isFetching:s,error:r}=y.useGetOverviewQuery({path:e,database:t},{pollingInterval:a}),i=s&&void 0===n,o=Sn(n);return i?(0,d.jsx)(O.a,{size:"m"}):n||r?(0,d.jsxs)("div",{className:cs(),children:[r?(0,d.jsx)(k.o,{error:r}):null,n?(0,d.jsx)("div",{className:cs("result"),children:(0,d.jsx)(os,{value:o,extraTools:(0,d.jsx)(cn.b,{view:"flat-secondary",text:JSON.stringify(n)}),search:!0,collapsedInitially:!0})}):null]}):(0,d.jsx)("div",{className:cs("message-container"),children:"Empty"})};var us=a(60073);const ms=e=>{const{PathType:t,PathSubType:a}=(null===e||void 0===e?void 0:e.Self)||{};return n=t,(s=a)&&rt[s]||n&&it[n];var n,s},ps=e=>{var t;return null===e||void 0===e||null===(t=e.UserAttributes)||void 0===t?void 0:t.some((({Key:e,Value:t})=>"__async_replica"===e&&"true"===t))};var hs=a(5741),vs=a(82176);const gs=(0,vs.H)({values:{PathType:e=>null===e||void 0===e?void 0:e.substring(9),CreateStep:e=>(0,q.r6)(e,{defaultValue:f.Pd})},labels:{PathType:(0,hs.A)("common.type"),CreateStep:(0,hs.A)("common.created")}}),ys=({value:e,withSpeedLabel:t,...a})=>{const n=(0,da.z3)({value:e,withSpeedLabel:t,...a}),s=(0,da.z3)({value:e,withSpeedLabel:t,size:"b"});return(0,d.jsx)("span",{title:s,children:n})},xs=(e,t)=>e?(0,d.jsx)(ys,{value:e,...t}):null,fs=(0,vs.H)({values:{Type:e=>null===e||void 0===e?void 0:e.substring(10),State:e=>null===e||void 0===e?void 0:e.substring(11),KeyColumnNames:e=>null===e||void 0===e?void 0:e.join(", "),DataColumnNames:e=>null===e||void 0===e?void 0:e.join(", "),DataSize:xs},labels:{KeyColumnNames:"Columns",DataColumnNames:"Includes"}}),bs={[et.METERING_MODE_REQUEST_UNITS]:"request-units",[et.METERING_MODE_RESERVED_CAPACITY]:"reserved-capacity"},js=(0,vs.H)({values:{Partitions:e=>(0,q.ZV)((null===e||void 0===e?void 0:e.length)||0),PQTabletConfig:e=>{const t=Math.round(e.PartitionConfig.LifetimeSeconds/f.Jg*100)/100;return`${(0,q.ZV)(t)} hours`}},labels:{Partitions:"Partitions count",PQTabletConfig:"Retention"}}),Ts=(0,vs.H)({values:{Codecs:e=>e&&Object.values(e.Codecs||{}).join(", "),MeteringMode:e=>e&&bs[e]},labels:{MeteringMode:"Metering mode"}}),Ss=(0,vs.H)({values:{StorageLimitBytes:q.z3,WriteSpeedInBytesPerSecond:q.tC},labels:{StorageLimitBytes:"Retention storage",WriteSpeedInBytesPerSecond:"Partitions write speed"}}),ws=(0,vs.H)({values:{Mode:e=>null===e||void 0===e?void 0:e.substring(14),Format:e=>null===e||void 0===e?void 0:e.substring(16)}}),Ns=(0,vs.H)({values:{CPU:q.iM,Memory:xs,Storage:xs,Network:q.tC,ReadThroughput:q.tC,WriteThroughput:q.tC},defaultValueFormatter:q.ZV}),Es=(0,vs.H)({values:{FollowerCount:q.ZV},labels:{FollowerCountPerDataCenter:"FollowerCountPerDC"},defaultValueFormatter:e=>e&&String(e)}),Cs=(0,vs.H)({values:{FollowerCount:q.ZV,CrossDataCenterFollowerCount:q.ZV}}),Ps=(0,vs.H)({values:{DataSize:xs,IndexSize:xs,LastAccessTime:q.r6,LastUpdateTime:q.r6},defaultValueFormatter:q.ZV}),Is=new Set(["Type","State","DataSize","KeyColumnNames","DataColumnNames"]),Ds=({data:e})=>{var t;const a=ms(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:["No ",a," data"]});const n=null===(t=e.PathDescription)||void 0===t?void 0:t.TableIndex,s=[];let r;for(r in n)Is.has(r)&&s.push(fs(r,null===n||void 0===n?void 0:n[r]));return(0,d.jsx)(us.z_,{title:a,info:s})};var _s=a(10508);const As=JSON.parse('{"external-objects.source-type":"Source Type","external-objects.data-source":"Data Source","external-objects.location":"Location","external-objects.auth-method":"Auth Method","external-objects.auth-method.none":"None","external-objects.auth-method.service-account":"Service Account","view.query-text":"Query Text"}'),Rs=(0,he.g4)("ydb-tenant-objects-info",{en:As}),ks=(0,c.cn)("ydb-external-data-source-info"),Os=e=>{var t,a,n,s;const r=[{label:Rs("external-objects.source-type"),value:null===(t=e.PathDescription)||void 0===t||null===(a=t.ExternalDataSourceDescription)||void 0===a?void 0:a.SourceType}],i=null===(n=e.PathDescription)||void 0===n||null===(s=n.Self)||void 0===s?void 0:s.CreateStep;var o,l;Number(i)&&r.push(gs("CreateStep",null===(o=e.PathDescription)||void 0===o||null===(l=o.Self)||void 0===l?void 0:l.CreateStep));return r},Ms=e=>{var t;const{Location:a,Auth:n}=(null===(t=e.PathDescription)||void 0===t?void 0:t.ExternalDataSourceDescription)||{};return[...Os(e),{label:Rs("external-objects.location"),value:(0,d.jsx)(_s.c,{name:a,showStatus:!1,hasClipboardButton:!0,clipboardButtonAlwaysVisible:!0,className:ks("location")})},{label:Rs("external-objects.auth-method"),value:null!==n&&void 0!==n&&n.ServiceAccount?Rs("external-objects.auth-method.service-account"):Rs("external-objects.auth-method.none")}]},Ls=({data:e,prepareData:t})=>{const a=ms(null===e||void 0===e?void 0:e.PathDescription);return e?(0,d.jsx)(us.z_,{title:a,info:t(e)}):(0,d.jsxs)("div",{className:"error",children:["No ",a," data"]})},qs=({data:e})=>(0,d.jsx)(Ls,{data:e,prepareData:Ms});var zs=a(10755),Fs=a(25196);const Us=(0,c.cn)("ydb-external-table-info"),Qs=(e,t)=>{var a,n;const{CreateStep:s}=(null===(a=e.PathDescription)||void 0===a?void 0:a.Self)||{},{SourceType:r,DataSourcePath:i}=(null===(n=e.PathDescription)||void 0===n?void 0:n.ExternalTableDescription)||{},o=null===i||void 0===i?void 0:i.split("/").pop(),l=[{label:Rs("external-objects.source-type"),value:r}];return Number(s)&&l.push(gs("CreateStep",s)),l.push({label:Rs("external-objects.data-source"),value:i&&(0,d.jsx)("span",{title:i,children:(0,d.jsx)(Fs.K,{title:o||"",url:t})})}),l},$s=(e,t)=>{var a,n;const s=null===(a=e.PathDescription)||void 0===a||null===(n=a.ExternalTableDescription)||void 0===n?void 0:n.Location;return[...Qs(e,t),{label:Rs("external-objects.location"),value:(0,d.jsx)(_s.c,{name:s,showStatus:!1,hasClipboardButton:!0,clipboardButtonAlwaysVisible:!0,className:Us("location")})}]},Bs=({data:e,prepareData:t})=>{var a,n;const s=(0,zs.zy)(),r=(0,U.mA)(s),i=(0,U.Ow)({...r,schema:null===e||void 0===e||null===(a=e.PathDescription)||void 0===a||null===(n=a.ExternalTableDescription)||void 0===n?void 0:n.DataSourcePath}),o=ms(null===e||void 0===e?void 0:e.PathDescription);return e?(0,d.jsx)(us.z_,{title:o,info:t(e,i)}):(0,d.jsxs)("div",{className:"error",children:["No ",o," data"]})},Hs=({data:e})=>(0,d.jsx)(Bs,{data:e,prepareData:$s});var Ws=a(94695),Gs=a(57439);const Vs=JSON.parse('{"no-data":"No data"}'),Js=(0,he.g4)("ydb-definition-list",{en:Vs}),Ks=(0,c.cn)("ydb-definition-list");function Ys({title:e,items:t,nameMaxWidth:a=220,copyPosition:n="outside",className:s,itemClassName:r,...i}){return(0,d.jsxs)("div",{className:Ks(null),children:[e?(0,d.jsx)("div",{className:Ks("title"),children:e}):null,t.length?(0,d.jsx)(Gs.u,{items:t,nameMaxWidth:a,copyPosition:n,className:Ks("properties-list",s),itemClassName:Ks("item",r),...i}):Js("no-data")]})}function Zs({data:e}){const t=ms(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:["No ",t," data"]});const a=(e=>{var t,a;const n=null===(t=e.PathDescription)||void 0===t||null===(a=t.ViewDescription)||void 0===a?void 0:a.QueryText;return[{name:Rs("view.query-text"),copyText:n,content:n?(0,d.jsx)(Ws.YDBSyntaxHighlighter,{language:"yql",text:n}):null}]})(e);return(0,d.jsx)(Ys,{title:t,items:a})}function Xs({state:e}){return e?"StandBy"in e?(0,d.jsx)(Tt.J,{theme:"info",children:"Standby"}):"Paused"in e?(0,d.jsx)(Tt.J,{theme:"info",children:"Paused"}):"Done"in e?(0,d.jsx)(Tt.J,{theme:"success",children:"Done"}):"Error"in e?(0,d.jsx)(Tt.J,{theme:"danger",children:"Error"}):(0,d.jsx)(Tt.J,{size:"s",children:"Unknown"}):null}const er=JSON.parse('{"column.dstPath.name":"Dist","column.srcPath.name":"Source","everythingWithPrefix":"Everything with prefix:","noData":"No data.","title":"Replicated Paths"}'),tr=(0,he.g4)("ydb-diagnostics-async-replication-paths",{en:er}),ar=(0,c.cn)("ydb-async-replication-paths"),nr=[{name:tr("column.srcPath.name"),render:({row:e})=>e.SrcPath,sortAccessor:e=>e.SrcPath},{name:tr("column.dstPath.name"),render:({row:e})=>e.DstPath,sortAccessor:e=>e.DstPath}];function sr({config:e}){if(!e)return null;let t=tr("noData");var a,n;e.Everything&&(t=(0,d.jsxs)("span",{children:[tr("everythingWithPrefix")," ",(0,d.jsx)(De.E,{variant:"code-inline-2",children:null!==(a=null===(n=e.Everything)||void 0===n?void 0:n.DstPrefix)&&void 0!==a?a:"undefined"}),"."]}));return e.Specific&&(t=(0,d.jsx)(ce.l,{data:e.Specific.Targets,settings:f.jp,columns:nr})),(0,d.jsxs)("div",{className:ar(),children:[(0,d.jsx)("div",{className:ar("title"),children:tr("title")}),t]})}function rr({connection:e}){return e?e.StaticCredentials?(0,d.jsx)(Tt.J,{value:e.StaticCredentials.User,theme:"normal",children:"user"}):"OAuthToken"in e?"OAuth":"unknown":null}const ir=JSON.parse('{"credentials.label":"Credentials","noData":"No data for entity:","srcConnection.database.label":"Source Database Path","srcConnection.endpoint.label":"Source Cluster Endpoint","state.label":"State"}'),or=(0,he.g4)("ydb-diagnostics-async-replication-info",{en:ir});function lr({data:e}){var t,a;const n=ms(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:[or("noData")," ",n]});const s=function(e){var t,a;const n=(null===(t=e.PathDescription)||void 0===t?void 0:t.ReplicationDescription)||{},s=n.State,r=(null===(a=n.Config)||void 0===a?void 0:a.SrcConnectionParams)||{},{Endpoint:i,Database:o}=r,l=[];s&&l.push({name:or("state.label"),content:(0,d.jsx)(Xs,{state:s})});i&&l.push({name:or("srcConnection.endpoint.label"),copyText:i,content:(0,d.jsx)(De.E,{variant:"code-inline-2",children:i})});o&&l.push({name:or("srcConnection.database.label"),copyText:o,content:(0,d.jsx)(De.E,{variant:"code-inline-2",children:o})});r&&l.push({name:or("credentials.label"),content:(0,d.jsx)(rr,{connection:r})});return l}(e);return(0,d.jsxs)(_e.s,{direction:"column",gap:"4",children:[(0,d.jsx)(Ys,{title:n,items:s}),(0,d.jsx)(sr,{config:null===(t=e.PathDescription)||void 0===t||null===(a=t.ReplicationDescription)||void 0===a?void 0:a.Config})]})}const cr=JSON.parse('{"writeLagPopover":"Write lag, maximum among all topic partitions","writeIdleTimePopover":"Write idle time, maximum among all topic partitions"}'),dr=JSON.parse('{"writeLagPopover":"\u041b\u0430\u0433 \u0437\u0430\u043f\u0438\u0441\u0438, \u043c\u0430\u043a\u0441\u0438\u043c\u0430\u043b\u044c\u043d\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0441\u0440\u0435\u0434\u0438 \u0432\u0441\u0435\u0445 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439 \u0442\u043e\u043f\u0438\u043a\u0430","writeIdleTimePopover":"\u0412\u0440\u0435\u043c\u044f \u0431\u0435\u0437 \u0437\u0430\u043f\u0438\u0441\u0438, \u043c\u0430\u043a\u0441\u0438\u043c\u0430\u043b\u044c\u043d\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0441\u0440\u0435\u0434\u0438 \u0432\u0441\u0435\u0445 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439 \u0442\u043e\u043f\u0438\u043a\u0430"}'),ur=(0,he.g4)("ydb-diagnostics-overview-topic-stats",{ru:dr,en:cr}),mr=(0,c.cn)("ydb-overview-topic-stats"),pr=e=>[{label:"Store size",value:(0,q.z3)(e.storeSize)},{label:(0,d.jsx)(Da,{text:"Write idle time",popoverContent:(0,d.jsx)(Ba,{text:ur("writeIdleTimePopover"),type:"write"})}),value:(0,ze.Bi)(e.partitionsIdleTime)},{label:(0,d.jsx)(Da,{text:"Write lag",popoverContent:(0,d.jsx)(Ba,{text:ur("writeLagPopover"),type:"write"})}),value:(0,ze.Bi)(e.partitionsWriteLag)},{label:"Average write speed",value:(0,d.jsx)(Ta,{data:e.writeSpeed,withValue:!1})}],hr=e=>{const t=e.writeSpeed;return[{label:"per minute",value:(0,q.tC)(t.perMinute)},{label:"per hour",value:(0,q.tC)(t.perHour)},{label:"per day",value:(0,q.tC)(t.perDay)}]},vr=({path:e,database:t})=>{const[a]=(0,b.Nt)(),{currentData:s,isFetching:r,error:i}=ua.useGetTopicQuery({path:e,database:t},{pollingInterval:a}),o=r&&void 0===s,l=(0,b.N4)((a=>ga(a,e,t)));if(o)return(0,d.jsx)("div",{className:mr(),children:(0,d.jsx)(O.a,{size:"s"})});const c=i||!l?(0,d.jsx)(k.o,{error:i}):null;return(0,d.jsxs)("div",{className:mr(),children:[(0,d.jsx)("div",{className:mr("title"),children:"Stats"}),c,l?(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)("div",{className:mr("info"),children:(0,d.jsx)(us.z_,{info:pr(l),multilineLabels:!0})}),(0,d.jsx)("div",{className:mr("bytes-written"),children:(0,d.jsx)(us.z_,{info:hr(l)})})]}):null]})},gr=e=>{var t,a,n;if(!e)return[];const s=null===e||void 0===e||null===(t=e.PathDescription)||void 0===t?void 0:t.CdcStreamDescription,{Mode:r,Format:i}=s||{},o=(0,us.jl)(ws,{Mode:r,Format:i}),l=null===e||void 0===e||null===(a=e.PathDescription)||void 0===a||null===(n=a.Self)||void 0===n?void 0:n.CreateStep;return Number(l)&&o.unshift(gs("CreateStep",l)),o},yr=({path:e,database:t,data:a})=>{const n=ms(null===a||void 0===a?void 0:a.PathDescription);return a?(0,d.jsxs)("div",{children:[(0,d.jsx)(us.z_,{title:n,info:gr(a)}),(0,d.jsx)(vr,{path:e,database:t})]}):(0,d.jsxs)("div",{className:"error",children:["No ",n," data"]})},xr=JSON.parse('{"page.title":"Database","pages.query":"Query","pages.diagnostics":"Diagnostics","summary.navigation":"Navigation","summary.showPreview":"Show preview","summary.source-type":"Source Type","summary.data-source":"Data Source","summary.copySchemaPath":"Copy schema path","summary.type":"Type","summary.subtype":"SubType","summary.id":"Id","summary.version":"Version","summary.created":"Created","summary.data-size":"Data size","summary.row-count":"Row count","summary.partitions":"Partitions count","summary.paths":"Paths","summary.shards":"Shards","summary.state":"State","summary.mode":"Mode","summary.format":"Format","summary.retention":"Retention","label.read-only":"ReadOnly","actions.copied":"The path is copied to the clipboard","actions.notCopied":"Couldn\u2019t copy the path","actions.copyPath":"Copy path","actions.connectToDB":"Connect to DB","actions.dropIndex":"Drop index","actions.openPreview":"Open preview","actions.createTable":"Create table...","actions.createExternalTable":"Create external table...","actions.createTopic":"Create topic...","actions.createColumnTable":"Create column table...","actions.createAsyncReplication":"Create async replication...","actions.createTransfer":"Create transfer...","actions.createView":"Create view...","actions.dropTable":"Drop table...","actions.dropTopic":"Drop topic...","actions.dropView":"Drop view...","actions.alterTable":"Alter table...","actions.manageColumns":"Manage columns...","actions.manageAutoPartitioning":"Manage auto partitioning...","actions.addTableIndex":"Add index...","actions.createCdcStream":"Create changefeed...","actions.alterTopic":"Alter topic...","actions.selectQuery":"Select query...","actions.upsertQuery":"Upsert query...","actions.alterReplication":"Alter async replicaton...","actions.alterTransfer":"Alter transfer...","actions.dropReplication":"Drop async replicaton...","actions.dropTransfer":"Drop transfer...","actions.createDirectory":"Create directory","schema.tree.dialog.placeholder":"Relative path","schema.tree.dialog.invalid":"Invalid path","schema.tree.dialog.whitespace":"Whitespace is not allowed","schema.tree.dialog.empty":"Path is empty","schema.tree.dialog.header":"Create directory","schema.tree.dialog.description":"Inside","schema.tree.dialog.buttonCancel":"Cancel","schema.tree.dialog.buttonApply":"Create"}'),fr=(0,he.g4)("ydb-tenant",{en:xr});function br({data:e}){const t=ms(e);return ps(e)?(0,d.jsxs)(_e.s,{gap:1,wrap:"nowrap",children:[t," ",(0,d.jsx)(Tt.J,{children:fr("label.read-only")})]}):t}const jr=JSON.parse('{"tableStats":"Table Stats","tabletMetrics":"Tablet Metrics","partitionConfig":"Partition Config","label.ttl":"TTL for rows","value.ttl":"column: \'{{columnName}}\', expire after: {{expireTime}}","label.standalone":"Standalone","label.partitioning":"Partitioning","label.partitioning-by-size":"Partitioning by size","value.partitioning-by-size.enabled":"Enabled, split size: {{size}}","label.partitioning-by-load":"Partitioning by load","label.partitions-min":"Min number of partitions","label.partitions-max":"Max number of partitions","label.read-replicas":"Read replicas (followers)","label.bloom-filter":"Bloom filter","enabled":"Enabled","disabled":"Disabled"}'),Tr=(0,he.g4)("ydb-diagnostics-overview-table-info",{en:jr});var Sr=a(62091),wr=a.n(Sr),Nr=a(7435),Er=a(41650);const Cr=e=>{if(e.Enabled&&e.Enabled.ColumnName&&void 0!==e.Enabled.ExpireAfterSeconds){const t=Tr("value.ttl",{columnName:e.Enabled.ColumnName,expireTime:(0,ze.Bi)(1e3*e.Enabled.ExpireAfterSeconds,1)});return{label:Tr("label.ttl"),value:t}}};const Pr=(e,t)=>{if(!e)return{};const{PathDescription:a={}}=e,{TableStats:n={},TabletMetrics:s={},Table:{PartitionConfig:r={},TTLSettings:i}={},ColumnTableDescription:o={}}=a,{PartCount:l,RowCount:c,DataSize:u,IndexSize:m,ByKeyFilterSize:p,LastAccessTime:h,LastUpdateTime:v,ImmediateTxCompleted:g,PlannedTxCompleted:y,TxRejectedByOverload:x,TxRejectedBySpace:f,TxCompleteLagMsec:b,InFlightTxCount:j,RowUpdates:T,RowDeletes:S,RowReads:w,RangeReads:N,RangeReadRows:E}=n,{FollowerGroups:C,FollowerCount:P,CrossDataCenterFollowerCount:I}=r;let D=[];switch(t){case Ye.EPathTypeTable:D=((e,t)=>{var a;const{PartitioningPolicy:n={},FollowerGroups:s,EnableFilterByKey:r}=e,i=[],o=n.SizeToSplit&&Number(n.SizeToSplit)>0?Tr("value.partitioning-by-size.enabled",{size:(0,q.z3)(n.SizeToSplit)}):Tr("disabled"),l=null!==(a=n.SplitByLoadSettings)&&void 0!==a&&a.Enabled?Tr("enabled"):Tr("disabled");if(i.push({label:Tr("label.partitioning-by-size"),value:o},{label:Tr("label.partitioning-by-load"),value:l},{label:Tr("label.partitions-min"),value:(0,q.ZV)(n.MinPartitionsCount||0)}),n.MaxPartitionsCount&&i.push({label:Tr("label.partitions-max"),value:(0,q.ZV)(n.MaxPartitionsCount)}),s&&s.length){const{RequireAllDataCenters:e,FollowerCountPerDataCenter:t,FollowerCount:a}=s[0];let n;n=e&&t?`PER_AZ: ${a}`:`ANY_AZ: ${a}`,i.push({label:Tr("label.read-replicas"),value:n})}if(t){const e=Cr(t);e&&i.push(e)}return(0,Nr.f8)(r)&&i.push({label:Tr("label.bloom-filter"),value:Tr(r?"enabled":"disabled")}),i})(r,i);break;case Ye.EPathTypeColumnTable:D=function(e){var t,a;const n=[];var s;if(n.push({label:Tr("label.standalone"),value:String((s=e,!(s.SchemaPresetName&&void 0!==s.SchemaPresetId)))}),null!==(t=e.Sharding)&&void 0!==t&&null!==(a=t.HashSharding)&&void 0!==a&&a.Columns){const t=`PARTITION BY HASH(${e.Sharding.HashSharding.Columns.join(", ")})`;n.push({label:Tr("label.partitioning"),value:(0,d.jsx)(De.E,{variant:"code-2",wordBreak:"break-word",children:t})})}if(e.TtlSettings){const t=Cr(null===e||void 0===e?void 0:e.TtlSettings);t&&n.push(t)}return n}(o)}const _=(0,us.jl)(Ps,{PartCount:l,RowCount:c,DataSize:u,IndexSize:m});(0,Er.kf)(p)&&(r.EnableFilterByKey||Number(p)>0)&&_.push({label:"BloomFilterSize",value:xs(p)});const A=[_,(0,us.jl)(Ps,{LastAccessTime:h,LastUpdateTime:v}),(0,us.jl)(Ps,{ImmediateTxCompleted:g,PlannedTxCompleted:y,TxRejectedByOverload:x,TxRejectedBySpace:f,TxCompleteLagMsec:b,InFlightTxCount:j}),(0,us.jl)(Ps,{RowUpdates:T,RowDeletes:S,RowReads:w,RangeReads:N,RangeReadRows:E})],R=(0,us.jl)(Ns,wr()(s,["GroupReadIops","GroupReadThroughput","GroupWriteIops","GroupWriteThroughput"]));let k=[];return Array.isArray(C)&&C.length>0?k=(0,us.jl)(Es,C[0]):void 0!==P?k.push(Cs("FollowerCount",P)):void 0!==I&&k.push(Cs("CrossDataCenterFollowerCount",I)),{generalInfo:D,tableStatsInfo:A,tabletMetricsInfo:R,partitionConfigInfo:k}},Ir=(0,c.cn)("ydb-diagnostics-table-info"),Dr=({data:e,type:t})=>{const a=(0,d.jsx)(br,{data:null===e||void 0===e?void 0:e.PathDescription}),{generalInfo:s,tableStatsInfo:r,tabletMetricsInfo:i=[],partitionConfigInfo:o=[]}=n.useMemo((()=>Pr(e,t)),[e,t]);return(0,d.jsxs)("div",{className:Ir(),children:[(0,d.jsx)(us.z_,{info:s,title:a,className:Ir("info-block"),renderEmptyState:()=>(0,d.jsx)("div",{className:Ir("title"),children:a})}),(0,d.jsxs)("div",{className:Ir("row"),children:[r?(0,d.jsx)("div",{className:Ir("col"),children:r.map(((e,t)=>(0,d.jsx)(us.z_,{info:e,title:0===t?Tr("tableStats"):void 0,className:Ir("info-block"),renderEmptyState:()=>null},t)))}):null,i.length>0||o.length>0?(0,d.jsxs)("div",{className:Ir("col"),children:[(0,d.jsx)(us.z_,{info:i,title:Tr("tabletMetrics"),className:Ir("info-block"),renderEmptyState:()=>null}),(0,d.jsx)(us.z_,{info:o,title:Tr("partitionConfig"),className:Ir("info-block"),renderEmptyState:()=>null})]}):null]})]})},_r=e=>{var t;const a=null===e||void 0===e||null===(t=e.PathDescription)||void 0===t?void 0:t.PersQueueGroup;if(!a)return[];const{Partitions:n=[],PQTabletConfig:s={PartitionConfig:{LifetimeSeconds:0}}}=a,{Codecs:r,MeteringMode:i}=s,{WriteSpeedInBytesPerSecond:o,StorageLimitBytes:l}=s.PartitionConfig;return[...(0,us.jl)(js,{Partitions:n,PQTabletConfig:s}),...(0,us.jl)(Ss,{StorageLimitBytes:l,WriteSpeedInBytesPerSecond:o}),...(0,us.jl)(Ts,{Codecs:r,MeteringMode:i})]},Ar=({data:e,path:t,database:a})=>{const n=ms(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:["No ",n," data"]});return(0,d.jsxs)("div",{children:[(0,d.jsx)(us.z_,{title:n,info:_r(e)}),(()=>{var n,s;return(null===(n=e.PathDescription)||void 0===n||null===(s=n.Self)||void 0===s?void 0:s.PathSubType)===Ze.EPathSubTypeStreamImpl?null:(0,d.jsx)(vr,{path:t,database:a})})()]})},Rr=g.F.injectEndpoints({endpoints:e=>({getReplication:e.query({queryFn:async e=>{try{const t=await window.api.viewer.getReplication(e);return"object"!==typeof t?{error:{}}:{data:t}}catch(t){return{error:t}}},providesTags:["All"]})}),overrideExisting:"throw"});function kr({connection:e}){return e?e.StaticCredentials?(0,d.jsx)(Tt.J,{value:e.StaticCredentials.User,theme:"normal",children:"user"}):"OAuthToken"in e?"OAuth":"unknown":null}const Or=JSON.parse('{"credentials.label":"Credentials","noData":"No data for entity:","srcConnection.database.label":"Source Database Path","srcConnection.endpoint.label":"Source Cluster Endpoint","state.label":"State","state.error":"Error","srcPath.label":"Source Topic","dstPath.label":"Destination Table","transformLambda.label":"Transformation Lambda"}'),Mr=(0,he.g4)("ydb-diagnostics-transfer-info",{en:Or});function Lr({path:e,database:t,data:a}){const n=ms(null===a||void 0===a?void 0:a.PathDescription);if(!a)return(0,d.jsxs)("div",{className:"error",children:[Mr("noData")," ",n]});const{data:s}=Rr.useGetReplicationQuery({path:e,database:t},{}),r=function(e,t){var a,n,s,r,i,o;const l=(null===(a=e.PathDescription)||void 0===a?void 0:a.ReplicationDescription)||{},c=l.State,u=(null===(n=l.Config)||void 0===n?void 0:n.SrcConnectionParams)||{},{Endpoint:m,Database:p}=u,h=null===(s=l.Config)||void 0===s||null===(r=s.TransferSpecific)||void 0===r?void 0:r.Target,v=null===h||void 0===h?void 0:h.SrcPath,g=null===h||void 0===h?void 0:h.DstPath,y=null===h||void 0===h?void 0:h.TransformLambda,x=[];c&&x.push({name:Mr("state.label"),content:(0,d.jsx)(Xs,{state:c})});null!==t&&void 0!==t&&null!==(i=t.error)&&void 0!==i&&i.issues&&null!==(o=t.error.issues[0])&&void 0!==o&&o.message&&x.push({name:Mr("state.error"),copyText:t.error.issues[0].message,content:(0,d.jsx)(De.E,{variant:"code-inline-2",color:"danger",children:t.error.issues[0].message})});m&&x.push({name:Mr("srcConnection.endpoint.label"),copyText:m,content:(0,d.jsx)(De.E,{variant:"code-inline-2",children:m})});p&&x.push({name:Mr("srcConnection.database.label"),copyText:p,content:(0,d.jsx)(De.E,{variant:"code-inline-2",children:p})});u&&x.push({name:Mr("credentials.label"),content:(0,d.jsx)(kr,{connection:u})});return x.push({name:Mr("srcPath.label"),copyText:v,content:(0,d.jsx)(De.E,{variant:"code-inline-2",children:v})}),x.push({name:Mr("dstPath.label"),copyText:g,content:(0,d.jsx)(De.E,{variant:"code-inline-2",children:g})}),x.push({name:Mr("transformLambda.label"),copyText:y,content:y?(0,d.jsx)(Ws.YDBSyntaxHighlighter,{language:"yql",text:y}):null}),x}(a,s);return(0,d.jsx)(_e.s,{direction:"column",gap:"4",children:(0,d.jsx)(Ys,{title:n,items:r})})}const qr=function({type:e,path:t,database:a}){const[s]=(0,b.Nt)(),{currentData:r,isFetching:i,error:o}=y.useGetOverviewQuery({path:t,database:a},{pollingInterval:s});return i&&void 0===r?(0,d.jsx)(O.a,{size:"m"}):(0,d.jsxs)(n.Fragment,{children:[o?(0,d.jsx)(k.o,{error:o}):null,o&&!r?null:(()=>{var n;const s=null!==r&&void 0!==r?r:void 0,i={[Ye.EPathTypeInvalid]:void 0,[Ye.EPathTypeDir]:void 0,[Ye.EPathTypeResourcePool]:void 0,[Ye.EPathTypeTable]:void 0,[Ye.EPathTypeSubDomain]:void 0,[Ye.EPathTypeTableIndex]:()=>(0,d.jsx)(Ds,{data:s}),[Ye.EPathTypeExtSubDomain]:void 0,[Ye.EPathTypeColumnStore]:void 0,[Ye.EPathTypeColumnTable]:void 0,[Ye.EPathTypeCdcStream]:()=>(0,d.jsx)(yr,{path:t,database:a,data:s}),[Ye.EPathTypePersQueueGroup]:()=>(0,d.jsx)(Ar,{data:s,path:t,database:a}),[Ye.EPathTypeExternalTable]:()=>(0,d.jsx)(Hs,{data:s}),[Ye.EPathTypeExternalDataSource]:()=>(0,d.jsx)(qs,{data:s}),[Ye.EPathTypeView]:()=>(0,d.jsx)(Zs,{data:s}),[Ye.EPathTypeReplication]:()=>(0,d.jsx)(lr,{data:s}),[Ye.EPathTypeTransfer]:()=>(0,d.jsx)(Lr,{path:t,database:a,data:s})};return e&&(null===(n=i[e])||void 0===n?void 0:n.call(i))||(0,d.jsx)(Dr,{data:s,type:e})})()]})};var zr,Fr=a(74417),Ur=a(91364);function Qr({href:e,className:t,size:a="xs"}){return(0,d.jsx)(dn.$,{href:e,target:"_blank",className:t,size:a,title:"Database logs",children:(0,d.jsx)(Re.I,{data:Ur.A})})}function $r(){return $r=Object.assign?Object.assign.bind():function(e){for(var t=1;t({getChartData:e.query({queryFn:async(e,{signal:t})=>{try{const a=await(async({database:e,metrics:t,timeFrame:a,maxDataPoints:n},{signal:s}={})=>{const r=t.map((e=>`target=${e.target}`)).join("&"),i=Math.round(Date.now()/1e3),o=i-ai[a];return window.api.viewer.getChartData({target:r,from:o,until:i,maxDataPoints:n,database:e},{signal:s})})(e,{signal:t});if(Array.isArray(a)){return{data:((e=[],t)=>{const a=e.map((({datapoints:e,target:a})=>{const n=t.find((e=>e.target===a));if(!n)return;const s=e.map((e=>e[0]));return{...n,data:s}})).filter((e=>void 0!==e));return{timeline:e[0].datapoints.map((e=>1e3*e[1])),metrics:a}})(a,e.metrics)}}return{error:new Error("string"===typeof a?si("not-supported"):a.error)}}catch(a){return{error:a}}},providesTags:["All"],keepUnusedDataFor:0})}),overrideExisting:"throw"}),ii=(0,c.cn)("ydb-metric-chart");Vr.W.set({plugins:[Kr.YagrPlugin]});const oi=(e,t={})=>{const{dataType:a,scaleRange:n,showLegend:s}=t,r=(e=>{switch(e){case"ms":return Xr;case"size":return ei;case"percent":return ti;default:return}})(a),i=!e.metrics.length,o=e.metrics.map(((e,t)=>{const a=e.color||Zr[t],n=function(e,t){const a=(0,Yr.Mj)(e);if(!a.isValid())throw new Error("Invalid color is passed");return a.alpha(t).toRgbString()}(a,.1);return{id:e.target,name:e.title||e.target,data:e.data,formatter:r,lineColor:a,color:n,legendColorKey:"lineColor"}}));return{data:{timeline:e.timeline,graphs:o},libraryConfig:{chart:{size:{padding:i?[10,0,10,0]:void 0},series:{type:"area",spanGaps:!0,lineWidth:1.5},select:{zoom:!1}},scales:{y:{type:"linear",range:"nice",min:(null===n||void 0===n?void 0:n.min)||0,max:null===n||void 0===n?void 0:n.max}},axes:{y:{values:r?(e,t)=>t.map(r):void 0}},tooltip:{show:!0,tracking:"sticky"},legend:{show:s}}}},li={timeline:[],metrics:[]},ci=({database:e,title:t,metrics:a,timeFrame:s="1h",autorefresh:r,width:i=400,height:o=i/1.5,chartOptions:l,onChartDataStatusChange:c,isChartVisible:u})=>{const{currentData:m,error:p,isFetching:h,status:v}=ri.useGetChartDataQuery({database:e,metrics:a,timeFrame:s,maxDataPoints:i/2},{pollingInterval:r}),g=h&&!m;n.useEffect((()=>null===c||void 0===c?void 0:c("fulfilled"===v?"success":"loading")),[v,c]);const y=oi(m||li,l);return(0,d.jsxs)("div",{className:ii(null),style:{height:o,width:i},children:[(0,d.jsx)("div",{className:ii("title"),children:t}),g?(0,d.jsx)(O.a,{}):u?(0,d.jsxs)("div",{className:ii("chart"),children:[(0,d.jsx)(Jr.Ay,{type:"yagr",data:y}),p?(0,d.jsx)(k.o,{className:ii("error"),error:p}):null]}):null]})},di=(0,c.cn)("ydb-timeframe-selector"),ui=({value:e,onChange:t,className:a})=>(0,d.jsx)("div",{className:di(null,a),children:Object.keys(ai).map((a=>(0,d.jsx)(dn.$,{view:"flat",selected:e===a,onClick:()=>t(a),children:a},a)))}),mi=(0,c.cn)("ydb-tenant-dashboard"),pi=({database:e,charts:t})=>{const[a,s]=n.useState(!0),[i="1h",o]=(0,r.useQueryParam)("timeframe",r.StringParam),[l]=(0,b.Nt)(),c=a?0:l,u=e=>{"success"===e&&s(!1)},m=1===t.length?872:428,p=428/1.5;return(0,d.jsxs)("div",{className:mi(null),style:{display:a?"none":void 0},children:[(0,d.jsx)("div",{className:mi("controls"),children:(0,d.jsx)(ui,{value:i,onChange:o})}),(0,d.jsx)("div",{className:mi("charts"),children:t.map((t=>{const n=t.metrics.map((({target:e})=>e)).join("&");return(0,d.jsx)(ci,{database:e,title:t.title,metrics:t.metrics,timeFrame:i,chartOptions:t.options,autorefresh:c,width:m,height:p,onChartDataStatusChange:u,isChartVisible:!a},n)}))})]})},hi=JSON.parse('{"no-data":"No data","no-pools-data":"No pools data","top-nodes.empty-data":"No such nodes","top-groups.empty-data":"No such groups","top":"Top","nodes":"nodes","shards":"shards","groups":"groups","queries":"queries","tables":"tables","by-pools-usage":"by pools usage","by-cpu-time":"by cpu time, {{executionPeriod}}","by-cpu-usage":"by cpu usage","by-load":"by load","by-memory":"by memory","by-usage":"by usage","by-size":"by size","cards.cpu-label":"CPU","cards.storage-label":"Storage","cards.memory-label":"Memory","charts.queries-per-second":"Queries per second","charts.transaction-latency":"Transactions latencies {{percentile}}","charts.cpu-usage":"CPU usage by pool","charts.storage-usage":"Tablet storage usage","charts.memory-usage":"Memory usage","storage.tablet-storage-title":"Tablet storage","storage.tablet-storage-description":"Size of user data and indexes stored in schema objects (tables, topics, etc.)","storage.db-storage-title":"Database storage","storage.db-storage-description":"Size of data stored in distributed storage with all overheads for redundancy","executed-last-hour":"executed in the last hour","column-header.process":"Process"}'),vi=(0,he.g4)("ydb-diagnostics-tenant-overview",{en:hi}),gi=[{title:vi("charts.queries-per-second"),metrics:[{target:"queries.requests",title:vi("charts.queries-per-second")}]},{title:vi("charts.transaction-latency",{percentile:""}),metrics:[{target:"queries.latencies.p50",title:"p50"},{target:"queries.latencies.p75",title:"p75"},{target:"queries.latencies.p90",title:"p90"},{target:"queries.latencies.p99",title:"p99"}],options:{dataType:"ms",showLegend:!0}}],yi=({database:e})=>(0,d.jsx)(pi,{database:e,charts:gi});var xi=a(67157);const fi=g.F.injectEndpoints({endpoints:e=>({getHealthcheckInfo:e.query({queryFn:async({database:e,maxLevel:t},{signal:a})=>{try{return{data:await window.api.viewer.getHealthcheckInfo({database:e,maxLevel:t},{signal:a})}}catch(n){return{error:n}}},providesTags:["All"]})}),overrideExisting:"throw"}),bi={RED:0,ORANGE:1,YELLOW:2,BLUE:3,GREEN:4},ji=e=>e.sort(((e,t)=>(bi[e.status]||0)-(bi[t.status]||0))),Ti=({issue:e,data:t})=>ji(t.filter((t=>e.reason&&-1!==e.reason.indexOf(t.id)))),Si=({data:e,roots:t})=>t?t.map((t=>{const a=Si({roots:Ti({issue:t,data:e}),data:e});return{...t,reasonsItems:a}})):[],wi=(0,ca.Mz)((e=>e),(e=>fi.endpoints.getHealthcheckInfo.select({database:e}))),Ni=(0,ca.Mz)((e=>e),((e,t)=>wi(t)),((e,t)=>{var a;return(null===(a=t(e).data)||void 0===a?void 0:a.issue_log)||[]})),Ei=(0,ca.Mz)(Ni,((e=[])=>{return ji((t=e).filter((e=>!t.find((t=>t.reason&&-1!==t.reason.indexOf(e.id))))));var t})),Ci=(0,ca.Mz)([Ni,Ei],((e=[],t=[])=>Si({data:e,roots:t}))),Pi=(0,ca.Mz)(Ni,((e=[])=>(e=>{const t={};for(const a of e)t[a.status]||(t[a.status]=0),t[a.status]++;return Object.entries(t).sort((([e],[t])=>(bi[e]||0)-(bi[t]||0)))})(e)));let Ii=function(e){return e.UNSPECIFIED="UNSPECIFIED",e.GOOD="GOOD",e.DEGRADED="DEGRADED",e.MAINTENANCE_REQUIRED="MAINTENANCE_REQUIRED",e.EMERGENCY="EMERGENCY",e}({}),Di=function(e){return e.UNSPECIFIED="UNSPECIFIED",e.GREY="GREY",e.GREEN="GREEN",e.BLUE="BLUE",e.YELLOW="YELLOW",e.ORANGE="ORANGE",e.RED="RED",e}({});var _i=a(63126),Ai=a(54090);const Ri={[Di.UNSPECIFIED]:Ai.m.Grey,[Di.GREY]:Ai.m.Grey,[Di.GREEN]:Ai.m.Green,[Di.BLUE]:Ai.m.Blue,[Di.YELLOW]:Ai.m.Yellow,[Di.ORANGE]:Ai.m.Orange,[Di.RED]:Ai.m.Red},ki=(0,c.cn)("issue-tree-item"),Oi=({status:e,message:t,type:a,onClick:n})=>(0,d.jsxs)("div",{className:ki(),onClick:n,children:[(0,d.jsx)("div",{className:ki("field",{status:!0}),children:(0,d.jsx)(_s.c,{mode:"icons",status:e,name:a})}),(0,d.jsx)("div",{className:ki("field",{message:!0}),children:t})]}),Mi=(0,c.cn)("issue-tree"),Li=({issueTree:e})=>{const[t,a]=n.useState({}),s=n.useCallback((e=>e?(0,d.jsx)("div",{className:Mi("info-panel"),children:(0,d.jsx)(os,{value:Tn(e)})}):null),[]),r=n.useCallback((e=>e.map((e=>{const{id:n}=e,{status:i,message:o,type:l,reasonsItems:c,level:u,...m}=e,p="undefined"===typeof t[n]||t[n],h=()=>{a((e=>({...e,[n]:!p})))};return(0,d.jsxs)(_i.G,{name:(0,d.jsx)(Oi,{status:Ri[i],message:o,type:l}),collapsed:p,hasArrow:!0,onClick:h,onArrowClick:h,level:u-1,children:[s(wr()(m,["reason"])),r(c||[])]},n)}))),[t,s]);return(0,d.jsx)("div",{className:Mi(),children:(0,d.jsx)("div",{className:Mi("block"),children:r([e])})})},qi=JSON.parse('{"title.healthcheck":"Healthcheck","label.update":"Update","label.show-details":"Show details","label.issues":"Issues:","status_message.ok":"No issues","no-data":"no healthcheck data"}'),zi=JSON.parse('{"title.healthcheck":"Healthcheck","label.update":"\u041e\u0431\u043d\u043e\u0432\u0438\u0442\u044c","label.show-details":"\u041f\u043e\u0441\u043c\u043e\u0442\u0440\u0435\u0442\u044c \u043f\u043e\u0434\u0440\u043e\u0431\u043d\u043e\u0441\u0442\u0438","label.issues":"\u041f\u0440\u043e\u0431\u043b\u0435\u043c\u044b:","status_message.ok":"\u041d\u0435\u0442 \u043f\u0440\u043e\u0431\u043b\u0435\u043c","no-data":"\u043d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445 healthcheck"}'),Fi=(0,he.g4)("ydb-diagnostics-healthcheck",{ru:zi,en:qi}),Ui=(0,c.cn)("healthcheck");function Qi({tenantName:e}){const[t]=(0,b.Nt)(),{name:a}=(0,xi.Zd)(),{issueTrees:s,loading:r,error:i}=((e,{autorefresh:t}={})=>{const{currentData:a,isFetching:n,error:s,refetch:r}=fi.useGetHealthcheckInfoQuery({database:e},{pollingInterval:t}),i=(null===a||void 0===a?void 0:a.self_check_result)||Ii.UNSPECIFIED,o=(0,b.N4)((t=>Pi(t,e)));return{issueTrees:(0,b.N4)((t=>Ci(t,e))),issuesStatistics:o,loading:void 0===a&&n,error:s,refetch:r,selfCheckResult:i}})(e,{autorefresh:"ydb_ru"===a?void 0:t});return(0,d.jsx)("div",{className:Ui("details"),children:(0,d.jsx)("div",{className:Ui("details-content-wrapper"),children:i?(0,d.jsx)(k.o,{error:i,defaultMessage:Fi("no-data")}):r?(0,d.jsx)(O.a,{size:"m"}):s&&s.length?(0,d.jsx)(n.Fragment,{children:s.map((e=>(0,d.jsx)(Li,{issueTree:e},e.id)))}):Fi("status_message.ok")})})}var $i=a(8861),Bi=a(73633),Hi=a(70825),Wi=a(43937),Gi=a(10800),Vi=a(71153);const Ji=(0,c.cn)("ydb-diagnostic-card");function Ki({children:e,className:t,active:a,size:n="m",interactive:s=!0}){return(0,d.jsx)("div",{className:Ji({active:a,size:n,interactive:s},t),children:e})}var Yi=a(52358);const Zi=(0,c.cn)("healthcheck"),Xi={[Ii.UNSPECIFIED]:Bi.A,[Ii.GOOD]:Hi.A,[Ii.DEGRADED]:Wi.A,[Ii.MAINTENANCE_REQUIRED]:Gi.A,[Ii.EMERGENCY]:Vi.A};function eo(e){const{tenantName:t,active:a}=e,[s]=(0,b.Nt)(),{metricsTab:r}=(0,b.N4)((e=>e.tenant)),{name:i}=(0,xi.Zd)(),o="ydb_ru"===i,{currentData:l,isFetching:c,error:u}=fi.useGetHealthcheckInfoQuery({database:t},{pollingInterval:o?void 0:s,skip:o}),[m,{currentData:p,isFetching:h}]=fi.useLazyGetHealthcheckInfoQuery();n.useEffect((()=>{"healthcheck"===r&&o&&m({database:t})}),[r,o,t,m]),n.useEffect((()=>{const e=()=>{o&&m({database:t})};return document.addEventListener("diagnosticsRefresh",e),()=>{document.removeEventListener("diagnosticsRefresh",e)}}),[t,o,m]);const v=c&&void 0===l||h&&void 0===p;return(0,d.jsxs)(Ki,{className:Zi("preview"),active:a,children:[(0,d.jsx)("div",{className:Zi("preview-header"),children:(0,d.jsxs)("div",{className:Zi("preview-title-wrapper"),children:[(0,d.jsx)("div",{className:Zi("preview-title"),children:Fi("title.healthcheck")}),o?(0,d.jsx)(ea.A,{content:"Healthcheck is disabled. Please update healthcheck manually.",placement:["top"],className:Zi("icon-wrapper"),children:()=>(0,d.jsx)(Re.I,{size:16,className:Zi("icon-warn"),data:Yi.A})}):null]})}),(()=>{if(u)return(0,d.jsx)(k.o,{error:u,defaultMessage:Fi("no-data")});if(v)return(0,d.jsx)(O.a,{size:"m"});const e=(null===l||void 0===l?void 0:l.self_check_result)||(null===p||void 0===p?void 0:p.self_check_result)||Ii.UNSPECIFIED,t=e.toLowerCase();return(0,d.jsx)("div",{className:Zi("preview-content"),children:(0,d.jsxs)("div",{className:Zi("preview-issue",{[t]:!0}),children:[(0,d.jsx)(Re.I,{className:Zi("preview-status-icon"),data:Xi[e]}),(0,d.jsx)("div",{className:Zi("self-check-status-indicator"),children:e.replace(/_/g," ")})]})})})()]})}var to=a(15132),ao=a(33775);const no=(0,c.cn)("ydb-metrics-card"),so=e=>{let t;return"Warning"===e&&(t=Ai.m.Yellow),"Danger"===e&&(t=Ai.m.Red),t?(0,d.jsx)(ao.k,{status:t,mode:"icons",size:"l"}):null};function ro({active:e,label:t,status:a,metrics:n}){return(0,d.jsxs)(Ki,{className:no({active:e}),active:e,children:[(0,d.jsxs)("div",{className:no("header"),children:[t&&(0,d.jsx)("div",{className:no("label"),children:t}),so(a)]}),(0,d.jsx)("div",{className:no("content"),children:n.map((({title:e,...t},a)=>(0,d.jsxs)("div",{className:no("metric"),children:[(0,d.jsx)("div",{className:no("metric-title"),children:e}),(0,d.jsx)(to.O,{size:"xs",colorizeProgress:!0,...t})]},a)))})]})}const io=(0,c.cn)("metrics-cards");function oo({poolsCpuStats:e,memoryStats:t,blobStorageStats:a,tabletStorageStats:n,tenantName:s}){const r=(0,zs.zy)(),{metricsTab:i}=(0,b.N4)((e=>e.tenant)),o=(0,U.mA)(r),l=e=>e===i?"":e,c={[S.pA.cpu]:(0,Pa.YL)({...o,[Pa.vh.metricsTab]:l(S.pA.cpu)}),[S.pA.storage]:(0,Pa.YL)({...o,[Pa.vh.metricsTab]:l(S.pA.storage)}),[S.pA.memory]:(0,Pa.YL)({...o,[Pa.vh.metricsTab]:l(S.pA.memory)}),[S.pA.healthcheck]:(0,Pa.YL)({...o,[Pa.vh.metricsTab]:l(S.pA.healthcheck)})};return(0,d.jsxs)("div",{className:io(),children:[(0,d.jsx)(N.N_,{to:c.cpu,className:io("tab"),children:(0,d.jsx)(lo,{poolsCpuStats:e,active:i===S.pA.cpu})}),(0,d.jsx)(N.N_,{to:c.storage,className:io("tab"),children:(0,d.jsx)(co,{blobStorageStats:a,tabletStorageStats:n,active:i===S.pA.storage})}),(0,d.jsx)(N.N_,{to:c.memory,className:io("tab"),children:(0,d.jsx)(uo,{memoryStats:t,active:i===S.pA.memory})}),(0,d.jsx)(N.N_,{to:c.healthcheck,className:io("tab"),children:(0,d.jsx)(eo,{tenantName:s,active:i===S.pA.healthcheck})})]})}function lo({poolsCpuStats:e=[],active:t}){let a=$i.u.Unspecified;const n=e.filter((e=>!("Batch"===e.name||"IO"===e.name))).map((e=>{const{name:t,usage:n,limit:s,used:r}=e,i=(0,Wr.sf)(n);return $i.Z[i]>$i.Z[a]&&(a=i),{title:t,value:r,capacity:s}}));return(0,d.jsx)(ro,{label:vi("cards.cpu-label"),active:t,metrics:n,status:a})}function co({blobStorageStats:e=[],tabletStorageStats:t,active:a}){let n=$i.u.Unspecified;const s=(t||e).map((e=>{const{name:t,used:a,limit:s,usage:r}=e,i=(0,Wr.sf)(r);return $i.Z[i]>$i.Z[n]&&(n=i),{title:t,value:a,capacity:s,formatValues:q.j9}}));return(0,d.jsx)(ro,{label:vi("cards.storage-label"),active:a,metrics:s,status:n})}function uo({active:e,memoryStats:t=[]}){let a=$i.u.Unspecified;const n=t.map((e=>{const{name:t,used:n,limit:s,usage:r}=e,i=(0,Wr.sf)(r);return $i.Z[i]>$i.Z[a]&&(a=i),{title:t,value:n,capacity:s,formatValues:q.j9}}));return(0,d.jsx)(ro,{label:vi("cards.memory-label"),active:e,metrics:n,status:a})}var mo=a(78762),po=a(86782),ho=a(15298),vo=a(40781);const go=(0,c.cn)("tenant-overview");function yo({title:e,error:t,loading:a,tableClassNameModifiers:s={},withData:r,children:i}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)("div",{className:go("title"),children:e}),t?(0,d.jsx)(k.o,{error:t}):null,(0,d.jsx)("div",{className:go("table",s),children:t&&!r?null:a?(0,d.jsx)(Ge.Q,{rows:f.Nz}):i})]})}var xo=a(82015);const fo=({prefix:e=vi("top"),entity:t,postfix:a,link:s,onClick:r})=>s?(0,d.jsxs)(n.Fragment,{children:[e," ",(0,d.jsx)(xo.E,{to:s,onClick:r,children:t})," ",a]}):`${e} ${t} ${a}`;function bo({tenantName:e,additionalNodesProps:t}){const a=(0,b.e4)(),[n]=(0,b.Nt)(),[s,r]=function(e){const t={...(0,mo.Nh)(e),width:void 0},a=[(0,mo.kv)(),(0,mo._E)(),t],n=a.map((e=>e.name));return[a,(0,vo.R)(n,po.fN)]}({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef,database:e}),{currentData:i,isFetching:o,error:l}=ho.s.useGetNodesQuery({tenant:e,type:"any",sort:"-CPU",limit:f.Nz,tablets:!1,fieldsRequired:r},{pollingInterval:n}),c=o&&void 0===i,u=(null===i||void 0===i?void 0:i.Nodes)||[],m=fo({entity:vi("nodes"),postfix:vi("by-pools-usage"),link:(0,Pa.YL)({...a,[Pa.vh.diagnosticsTab]:S.iJ.nodes})});return(0,d.jsx)(yo,{title:m,loading:c,error:l,withData:Boolean(i),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:po.zO,data:u,columns:s,emptyDataMessage:vi("top-nodes.empty-data"),settings:f.jp})})}function jo({tenantName:e,additionalNodesProps:t}){const a=(0,b.e4)(),[n]=(0,b.Nt)(),[s,r]=function(e){const t={...(0,mo.Nh)(e),width:void 0},a=[(0,mo.fR)(),(0,mo._E)(),t,(0,mo.Rn)()],n=a.map((e=>e.name));return[a,(0,vo.R)(n,po.fN)]}({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef,database:e}),{currentData:i,isFetching:o,error:l}=ho.s.useGetNodesQuery({tenant:e,type:"any",sort:"-LoadAverage",limit:f.Nz,tablets:!1,fieldsRequired:r},{pollingInterval:n}),c=o&&void 0===i,u=(null===i||void 0===i?void 0:i.Nodes)||[],m=fo({entity:vi("nodes"),postfix:vi("by-load"),link:(0,Pa.YL)({...a,[Pa.vh.diagnosticsTab]:S.iJ.nodes})});return(0,d.jsx)(yo,{title:m,loading:c,error:l,withData:Boolean(i),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:po.zO,data:u,columns:s,emptyDataMessage:vi("top-nodes.empty-data"),settings:f.jp})})}var To=a(12482),So=a(73289),wo=a(16332);const No=JSON.parse('{"action_cancel":"Cancel"}'),Eo=(0,he.g4)("ydb-confirmation-dialog",{en:No}),Co=(0,c.cn)("confirmation-dialog"),Po="confirmation-dialog";function Io({caption:e="",children:t,onConfirm:a,onClose:n,progress:s,textButtonApply:r,textButtonCancel:i,buttonApplyView:o="normal",className:l,renderButtons:c,open:u}){return(0,d.jsxs)(Fn.l,{className:Co(null,l),size:"s",onClose:n,disableOutsideClick:!0,open:u,children:[(0,d.jsx)(Fn.l.Header,{caption:(0,d.jsx)("span",{className:Co("caption"),children:e})}),(0,d.jsx)(Fn.l.Body,{children:t}),(0,d.jsx)(Fn.l.Footer,{onClickButtonApply:a,propsButtonApply:{view:o},textButtonApply:r,textButtonCancel:null!==i&&void 0!==i?i:Eo("action_cancel"),onClickButtonCancel:n,loading:s,renderButtons:c})]})}const Do=wo.vt((e=>{const t=wo.hS(),a=()=>{t.hide(),t.remove()};return(0,d.jsx)(Io,{...e,onConfirm:async()=>{var n;await(null===(n=e.onConfirm)||void 0===n?void 0:n.call(e)),t.resolve(!0),a()},onClose:()=>{var n;null===(n=e.onClose)||void 0===n||n.call(e),t.resolve(!1),a()},open:t.visible})}));wo.kz(Po,Do);var _o=a(40569),Ao=a(36894);function Ro(){const[e]=(0,b.iK)(f.ld,[]),t=(0,b.N4)(Ao.cu).toLowerCase();return t?e.filter((e=>e.body.toLowerCase().includes(t))):e}const ko=JSON.parse('{"action.save":"Save query","action.edit":"Edit query","action.save-as-new":"Save as new","action.edit-existing":"Edit existing","description":"The query will be saved in your browser","input-label":"Query name","input-placeholder":"Enter query name","button-apply":"Save","button-cancel":"Cancel","error.name-exists":"This name already exists","error.name-not-empty":"Name should not be empty"}'),Oo=(0,he.g4)("ydb-save-query-dialog",{en:ko}),Mo=(0,c.cn)("ydb-save-query");function Lo(e){const t=(0,b.YQ)();return n.useCallback((()=>{wo.Ay.show(Uo,e),t((0,Ao.gJ)())}),[t,e])}function qo({dialogProps:e,...t}){const a=Lo(e);return(0,d.jsx)(dn.$,{onClick:a,...t,children:Oo("action.save")})}function zo({buttonProps:e={}}){const t=(0,b.YQ)(),a=(0,b.N4)(Ao.aW),n=Lo(),s=()=>{t((0,Ao.Wg)(a)),t((0,So.Xb)(!1)),t((0,Ao.gJ)())};return a?(()=>{const t=[{action:s,text:Oo("action.edit-existing")},{action:n,text:Oo("action.save-as-new")}];return(0,d.jsx)(_o.r,{items:t,renderSwitcher:t=>(0,d.jsx)(dn.$,{...t,...e,children:Oo("action.edit")}),popupProps:{placement:"top"}})})():(0,d.jsx)(qo,{})}function Fo({onSuccess:e,onCancel:t,onClose:a,open:s}){const r=Ro(),i=(0,b.YQ)(),[o,l]=n.useState(""),[c,u]=n.useState(),m=()=>{i((0,Ao.NJ)("idle")),l(""),u(void 0),null===a||void 0===a||a()},p=()=>{null===t||void 0===t||t(),m()};return(0,d.jsxs)(Fn.l,{open:s,hasCloseButton:!1,size:"s",onClose:p,children:[(0,d.jsx)(Fn.l.Header,{caption:Oo("action.save")}),(0,d.jsxs)("form",{onSubmit:t=>{t.preventDefault();const a=(n=o)?r.some((e=>e.name.toLowerCase()===n.trim().toLowerCase()))?Oo("error.name-exists"):void 0:Oo("error.name-not-empty");var n;u(a),a||(i((0,Ao.Wg)(o)),i((0,So.Xb)(!1)),m(),null===e||void 0===e||e())},children:[(0,d.jsxs)(Fn.l.Body,{className:Mo("dialog-body"),children:[(0,d.jsx)("div",{className:Mo("dialog-row"),children:Oo("description")}),(0,d.jsxs)("div",{className:Mo("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"queryName",className:Mo("field-title","required"),children:Oo("input-label")}),(0,d.jsx)("div",{className:Mo("control-wrapper"),children:(0,d.jsx)(On.k,{id:"queryName",placeholder:Oo("input-placeholder"),value:o,onUpdate:e=>{l(e),u(void 0)},hasClear:!0,autoFocus:!0,autoComplete:!1,validationState:c?"invalid":void 0,errorMessage:c})})]})]}),(0,d.jsx)(Fn.l.Footer,{textButtonApply:Oo("button-apply"),textButtonCancel:Oo("button-cancel"),onClickButtonCancel:p,propsButtonApply:{type:"submit"}})]})]})}const Uo="save-query-dialog",Qo=wo.Ay.create((e=>{const t=wo.Ay.useModal();return(0,d.jsx)(Fo,{...e,onClose:()=>{var a;null===(a=e.onClose)||void 0===a||a.call(e),t.hide(),t.remove()},open:t.visible})}));wo.Ay.register(Uo,Qo);const $o=JSON.parse('{"action_apply":"Don\'t save","context_unsaved-changes-warning":"You have unsaved changes in query editor.\\nDo you want to proceed?"}'),Bo=(0,he.g4)("ydb-change-input-confirmation",{en:$o});function Ho(){const e=wo.Ay.useModal(Po),t=n.useCallback((()=>{e.hide(),e.remove()}),[e]),a=n.useCallback((()=>{e.resolve(!0),t()}),[e,t]),s=n.useCallback((()=>{e.resolve(!1),t()}),[t,e]),r=n.useMemo((()=>({onSuccess:a,onCancel:s})),[a,s]);return(0,d.jsx)(qo,{view:"action",size:"l",dialogProps:r})}async function Wo(){return await wo.Ay.show(Po,{id:Po,caption:Bo("context_unsaved-changes-warning"),textButtonApply:Bo("action_apply"),propsButtonApply:{view:"l"},renderButtons:(e,t)=>(0,d.jsxs)(n.Fragment,{children:[t,(0,d.jsx)(Ho,{}),e]})})}function Go(e){const t=(0,b.N4)(So.Wp),a=(0,b.N4)(So.TY),s=n.useMemo((()=>function(e){return async t=>{await Wo()&&e(t)}}(e)),[e]);return t&&a?s:e}const Vo=(0,c.cn)("kv-truncated-query"),Jo=({value:e="",maxQueryHeight:t=6,hasClipboardButton:a,clipboardButtonAlwaysVisible:s})=>{const r=e.split("\n");if(r.length>t){const i=r.slice(0,t).join("\n"),o="\n...\nThe request was truncated. Click on the line to show the full query on the query tab";return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Ws.YDBSyntaxHighlighter,{language:"yql",className:Vo(),text:i,withClipboardButton:!!a&&{alwaysVisible:s,copyText:e,withLabel:!1}}),(0,d.jsx)("span",{className:Vo("message",{color:"secondary"}),children:o})]})}return(0,d.jsx)(Ws.YDBSyntaxHighlighter,{language:"yql",text:e,withClipboardButton:!!a&&{alwaysVisible:s,copyText:e,withLabel:!1}})};var Ko=a(70206),Yo=a.n(Ko);const Zo=e=>(Yo().str(e)>>>0).toString(16).toUpperCase().padStart(8,"0"),Xo={...f.N3,dynamicRenderType:"variable"},el=JSON.parse('{"cpu-time":"CPU Time","read-rows":"Read Rows","read-bytes":"Read Bytes","query-hash":"Query Hash","user":"User","start-time":"Start time","end-time":"End time","duration":"Duration","query-text":"Query text","application":"Application","request-units":"Request Units"}'),tl=(0,he.g4)("ydb-top-queries-columns",{en:el}),al="topQueriesColumnsWidth",nl="CPUTime",sl="QueryText",rl="EndTime",il="ReadRows",ol="ReadBytes",ll="UserSID",cl="OneLineQueryText",dl="QueryHash",ul="Duration",ml="QueryStartAt",pl="ApplicationName",hl="RequestUnits",vl=["QueryHash","CPUTime","QueryText","EndTime","Duration","ReadRows","ReadBytes","RequestUnits","UserSID"],gl=["CPUTime","QueryText"],yl=["QueryHash","UserSID","QueryStartAt","QueryText","ApplicationName"],xl=["QueryStartAt","QueryText"],fl={get CPUTime(){return tl("cpu-time")},get QueryText(){return tl("query-text")},get EndTime(){return tl("end-time")},get ReadRows(){return tl("read-rows")},get ReadBytes(){return tl("read-bytes")},get UserSID(){return tl("user")},get OneLineQueryText(){return tl("query-text")},get QueryHash(){return tl("query-hash")},get Duration(){return tl("duration")},get QueryStartAt(){return tl("start-time")},get ApplicationName(){return tl("application")},get RequestUnits(){return tl("request-units")}},bl={CPUTime:"CPUTimeUs",QueryText:void 0,EndTime:void 0,ReadRows:void 0,ReadBytes:"ReadBytes",UserSID:void 0,OneLineQueryText:void 0,QueryHash:void 0,Duration:"Duration",QueryStartAt:void 0,ApplicationName:void 0,RequestUnits:"RequestUnits"},jl={CPUTime:void 0,QueryText:void 0,EndTime:void 0,ReadRows:void 0,ReadBytes:void 0,UserSID:"UserSID",OneLineQueryText:void 0,QueryHash:void 0,Duration:void 0,QueryStartAt:"QueryStartAt",ApplicationName:"ApplicationName",RequestUnits:void 0};function Tl(e){return bl[e]}function Sl(e){return jl[e]}const wl=(0,c.cn)("kv-top-queries"),Nl={name:nl,header:fl.CPUTime,render:({row:e})=>{var t;return(0,ze.Xo)((0,ze.Jc)(null!==(t=e.CPUTimeUs)&&void 0!==t?t:void 0))},width:120,align:Pt.Ay.RIGHT},El={name:sl,header:fl.QueryText,render:({row:e})=>{var t;return(0,d.jsx)("div",{className:wl("query"),children:(0,d.jsx)(Jo,{value:null===(t=e.QueryText)||void 0===t?void 0:t.toString(),maxQueryHeight:6,hasClipboardButton:!0})})},width:500},Cl={name:rl,header:fl.EndTime,render:({row:e})=>(0,q.r6)(new Date(e.EndTime).getTime()),align:Pt.Ay.RIGHT,width:200},Pl={name:il,header:fl.ReadRows,render:({row:e})=>(0,q.ZV)(e.ReadRows),align:Pt.Ay.RIGHT,width:150},Il={name:ol,header:fl.ReadBytes,render:({row:e})=>(0,q.ZV)(e.ReadBytes),align:Pt.Ay.RIGHT,width:150},Dl={name:ll,header:fl.UserSID,render:({row:e})=>(0,d.jsx)("div",{className:wl("user-sid"),children:e.UserSID||"\u2013"}),align:Pt.Ay.LEFT,width:120},_l={name:cl,header:fl.OneLineQueryText,render:({row:e})=>{var t;return(0,d.jsx)(Ws.YDBSyntaxHighlighter,{language:"yql",text:(null===(t=e.QueryText)||void 0===t?void 0:t.toString())||"",withClipboardButton:{withLabel:!1}})},width:500},Al={name:dl,header:fl.QueryHash,render:({row:e})=>Zo(String(e.QueryText)),width:130},Rl={name:ul,header:fl.Duration,render:({row:e})=>{var t;return(0,ze.Xo)((0,ze.Jc)(null!==(t=e.Duration)&&void 0!==t?t:void 0))},align:Pt.Ay.RIGHT,width:150},kl={name:ml,header:fl.QueryStartAt,render:({row:e})=>(0,q.r6)(new Date(e.QueryStartAt).getTime()),resizeable:!1,width:160},Ol={name:hl,header:fl.RequestUnits,render:({row:e})=>(0,q.ZV)(e.RequestUnits),align:Pt.Ay.RIGHT,width:150},Ml={name:pl,header:fl.ApplicationName,render:({row:e})=>(0,d.jsx)("div",{className:wl("user-sid"),children:e.ApplicationName||"\u2013"})};function Ll({tenantName:e}){var t,a;const s=(0,b.YQ)(),r=(0,zs.zy)(),i=(0,zs.W6)(),o=(0,U.mA)(r),[l]=(0,b.Nt)(),c=n.useMemo((()=>[Al,_l,Nl]),[]),{currentData:u,isFetching:m,error:p}=To.Ke.useGetTopQueriesQuery({database:e,timeFrame:"hour",limit:f.Nz},{pollingInterval:l}),h=m&&void 0===u,v=(null===u||void 0===u||null===(t=u.resultSets)||void 0===t||null===(a=t[0])||void 0===a?void 0:a.result)||[],g=Go(n.useCallback((e=>{const{QueryText:t}=e;s((0,So.iZ)({input:t})),s((0,So.Xb)(!1));const a=(0,U.mA)(r),n=(0,Pa.YL)({...a,[S.Dt]:S.Dg.query,[Pa.vh.queryTab]:S.tQ.newQuery});i.push(n)}),[s,i,r])),y=fo({entity:vi("queries"),postfix:vi("by-cpu-time",{executionPeriod:vi("executed-last-hour")}),onClick:()=>{s((0,To.TX)({from:void 0,to:void 0}))},link:(0,Pa.YL)({...o,[Pa.vh.diagnosticsTab]:S.iJ.topQueries})});return(0,d.jsx)(yo,{title:y,loading:h,error:(0,Ve.Cb)(p),withData:Boolean(u),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:al,data:v,columns:c,onRowClick:g,rowClassName:()=>go("top-queries-row"),settings:f.jp})})}var ql=a(34271);function zl(e,t){const a=`CAST(SUBSTRING(CAST(Path AS String), ${t.length}) AS Utf8) AS RelativePath`;return`${f.Zi}\nSELECT\n ${a},\n TabletId,\n CPUCores,\nFROM \`.sys/partition_stats\`\nWHERE\n Path='${e}'\n OR Path LIKE '${e}/%'\nORDER BY CPUCores DESC\nLIMIT ${f.Nz}`}const Fl=g.F.injectEndpoints({endpoints:e=>({getTopShards:e.query({queryFn:async({database:e,path:t=""},{signal:a})=>{try{const n=await window.api.viewer.sendQuery({query:zl(t,e),database:e,action:"execute-scan"},{signal:a,withRetries:!0});return(0,Ve.We)(n)?{error:n}:{data:(0,Ve.fW)(n)}}catch(n){return{error:n||new Error("Unauthorized")}}},providesTags:["All"]})}),overrideExisting:"throw"}),Ul=["TabletId","Path","CPUCores"],Ql=({tenantName:e,path:t})=>{var a,n;const s=(0,ql.x)("ShardsTable"),r=(0,zs.zy)(),i=(0,U.mA)(r),[o]=(0,b.Nt)(),{currentData:l,isFetching:c,error:u}=Fl.useGetTopShardsQuery({database:e,path:t},{pollingInterval:o}),m=c&&void 0===l,p=(null===l||void 0===l||null===(a=l.resultSets)||void 0===a||null===(n=a[0])||void 0===n?void 0:n.result)||[],h=fo({entity:vi("shards"),postfix:vi("by-cpu-usage"),link:(0,Pa.YL)({...i,[Pa.vh.diagnosticsTab]:S.iJ.topShards})});return(0,d.jsx)(yo,{title:h,loading:m,error:(0,Ve.Cb)(u),withData:Boolean(l),children:(0,d.jsx)(s,{data:p,schemaPath:e,database:e,columnsIds:Ul,settings:f.jp})})},$l=[{title:vi("charts.cpu-usage"),metrics:["IC","IO","Batch","User","System"].map((e=>({target:`resources.cpu.${e}.usage`,title:e}))),options:{dataType:"percent",scaleRange:{min:0,max:1},showLegend:!0}}];function Bl({tenantName:e,additionalNodesProps:t}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(pi,{database:e,charts:$l}),(0,d.jsx)(jo,{tenantName:e,additionalNodesProps:t}),(0,d.jsx)(bo,{tenantName:e,additionalNodesProps:t}),(0,d.jsx)(Ql,{tenantName:e,path:e}),(0,d.jsx)(Ll,{tenantName:e})]})}var Hl=a(73473);function Wl({tenantName:e,additionalNodesProps:t}){const a=(0,b.e4)(),[n]=(0,b.Nt)(),[s,r]=function(e){const t=[(0,mo._E)(),(0,mo.Nh)(e),(0,mo.jl)(),(0,mo.fR)(),(0,mo.iX)(),(0,mo.oz)(),(0,mo.qp)(e)],a=t.map((e=>e.name));return[t,(0,vo.R)(a,po.fN)]}({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef,database:e}),{currentData:i,isFetching:o,error:l}=ho.s.useGetNodesQuery({tenant:e,type:"any",tablets:!0,sort:"-Memory",limit:f.Nz,fieldsRequired:r},{pollingInterval:n}),c=o&&void 0===i,u=(null===i||void 0===i?void 0:i.Nodes)||[],m=fo({entity:vi("nodes"),postfix:vi("by-memory"),link:(0,Pa.YL)({...a,[Pa.vh.diagnosticsTab]:S.iJ.nodes})});return(0,d.jsx)(yo,{title:m,loading:c,error:l,withData:Boolean(i),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:po.zO,data:u,columns:s,emptyDataMessage:vi("top-nodes.empty-data"),settings:f.jp})})}const Gl=[{title:vi("charts.memory-usage"),metrics:[{target:"resources.memory.used_bytes",title:vi("charts.memory-usage")}],options:{dataType:"size"}}];function Vl({tenantName:e,memoryStats:t,memoryUsed:a,memoryLimit:s}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(pi,{database:e,charts:Gl}),(0,d.jsx)("div",{className:go("title"),children:"Memory details"}),(0,d.jsx)("div",{className:go("memory-info"),children:t?(0,d.jsx)(Hl.S,{formatValues:q.vX,stats:t}):(0,d.jsx)(to.O,{value:a,capacity:s,formatValues:q.vX,colorizeProgress:!0})}),(0,d.jsx)(Wl,{tenantName:e})]})}var Jl=a(18863),Kl=a(10174),Yl=a(74006),Zl=a(74319);function Xl({tenant:e}){const t=(0,b.e4)(),a=(0,D.Pm)(),n=(0,D.YA)(),[s]=(0,b.Nt)(),[r,i]=function(){const e=(0,Yl.k)(),t=e.map((e=>e.name));return[e,(0,vo.R)(t,Zl.YX)]}(),{currentData:o,isFetching:l,error:c}=Kl.S.useGetStorageGroupsInfoQuery({tenant:e,sort:"-Usage",with:"all",limit:f.Nz,shouldUseGroupsHandler:n,fieldsRequired:i},{pollingInterval:s,skip:!a}),u=l&&void 0===o,m=(null===o||void 0===o?void 0:o.groups)||[],p=fo({entity:vi("groups"),postfix:vi("by-usage"),link:(0,Pa.YL)({...t,[Pa.vh.diagnosticsTab]:S.iJ.storage})});return(0,d.jsx)(yo,{title:p,loading:u||!a,error:c,withData:Boolean(o),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:Zl.qK,data:m,columns:r,settings:f.jp})})}var ec=a(91135);const tc=g.F.injectEndpoints({endpoints:e=>({getTopTables:e.query({queryFn:async({database:e},{signal:t})=>{try{const a=await window.api.viewer.sendQuery({query:`${f.Zi}\nSELECT\n Path, SUM(DataSize) as Size\nFROM \`.sys/partition_stats\`\nGROUP BY Path\nORDER BY Size DESC\nLIMIT ${f.Nz}\n`,database:e,action:"execute-scan"},{signal:t,withRetries:!0});return(0,Ve.We)(a)?{error:a}:{data:(0,Ve.fW)(a)}}catch(a){return{error:a||"Unauthorized"}}},providesTags:["All"]})}),overrideExisting:"throw"});function ac({database:e}){var t,a;const[n]=(0,b.Nt)(),{currentData:s,error:r,isFetching:i}=tc.useGetTopTablesQuery({database:e},{pollingInterval:n}),o=i&&void 0===s,l=(null===s||void 0===s||null===(t=s.resultSets)||void 0===t||null===(a=t[0])||void 0===a?void 0:a.result)||[],c=[{name:"Size",width:100,render:({row:e})=>(e=>{const t=(0,da.fn)(null!==l&&void 0!==l&&l.length?Number(l[0].Size):0);return(0,da.z3)({value:e,size:t,precision:1})})(Number(e.Size)),align:Pt.Ay.RIGHT},{name:"Path",width:700,render:({row:e})=>e.Path?(0,d.jsx)(Oe.s,{content:e.Path,children:(0,d.jsx)(ec.I,{path:String(e.Path),children:e.Path})}):null}],u=fo({entity:vi("tables"),postfix:vi("by-size")});return(0,d.jsx)(yo,{title:u,loading:o,error:(0,Ve.Cb)(r),withData:Boolean(s),children:(0,d.jsx)(ce.l,{columnsWidthLSKey:"topTablesTableColumnsWidth",data:l,columns:c,settings:f.jp})})}const nc=[{title:vi("charts.storage-usage"),metrics:[{target:"resources.storage.used_bytes",title:vi("charts.storage-usage")}],options:{dataType:"size"}}];function sc({tenantName:e,metrics:t}){const{blobStorageUsed:a,tabletStorageUsed:s,blobStorageLimit:r,tabletStorageLimit:i}=t,o=[{label:(0,d.jsx)(Da,{text:vi("storage.tablet-storage-title"),popoverContent:vi("storage.tablet-storage-description")}),value:(0,d.jsx)(to.O,{value:s,capacity:i,formatValues:q.j9,colorizeProgress:!0})},{label:(0,d.jsx)(Da,{text:vi("storage.db-storage-title"),popoverContent:vi("storage.db-storage-description")}),value:(0,d.jsx)(to.O,{value:a,capacity:r,formatValues:q.j9,colorizeProgress:!0})}];return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(pi,{database:e,charts:nc}),(0,d.jsx)(Jl.z,{className:go("storage-info"),title:"Storage details",info:o}),(0,d.jsx)(ac,{database:e}),(0,d.jsx)(Xl,{tenant:e})]})}function rc({tenantName:e,additionalTenantProps:t,additionalNodesProps:a}){var n,s,r,i;const{metricsTab:o}=(0,b.N4)((e=>e.tenant)),[l]=(0,b.Nt)(),c=(0,Gr.H)(),{currentData:u,isFetching:m}=_.z6.useGetTenantInfoQuery({path:e,clusterName:c},{pollingInterval:l}),p=m&&void 0===u,{Name:h,Type:v,Overall:g}=u||{},x=(j=v)&&ot[j];var j;const{currentData:T}=y.useGetOverviewQuery({path:e,database:e},{pollingInterval:l}),{Tables:w,Topics:N}=(null===T||void 0===T||null===(n=T.PathDescription)||void 0===n||null===(s=n.DomainDescription)||void 0===s?void 0:s.DiskSpaceUsage)||{},E=[null===w||void 0===w?void 0:w.TotalSize,null===N||void 0===N?void 0:N.DataSize].reduce(((e,t)=>t?e+Number(t):e),0),C={...u,Metrics:{...null===u||void 0===u?void 0:u.Metrics,Storage:String(E)}},{blobStorage:P,tabletStorage:I,blobStorageLimit:D,tabletStorageLimit:A,poolsStats:R,memoryStats:k,blobStorageStats:O,tabletStorageStats:M}=(0,Wr.uI)(C),L={blobStorageUsed:P,blobStorageLimit:D,tabletStorageUsed:I,tabletStorageLimit:A};if(p)return(0,d.jsx)("div",{className:go("loader"),children:(0,d.jsx)(Fr.a,{size:"m"})});const q=null===t||void 0===t||null===(r=t.getMonitoringLink)||void 0===r?void 0:r.call(t,h,v),z=null===t||void 0===t||null===(i=t.getLogsLink)||void 0===i?void 0:i.call(t,h);return(0,d.jsxs)("div",{className:go(),children:[(0,d.jsxs)("div",{className:go("info"),children:[(0,d.jsx)("div",{className:go("top-label"),children:x}),(0,d.jsxs)(_e.s,{alignItems:"center",gap:"1",className:go("top"),children:[(0,d.jsx)("div",{className:go("tenant-name-wrapper"),children:(0,d.jsx)(_s.c,{status:g,name:h||f.oK,withLeftTrim:!0,hasClipboardButton:Boolean(u),clipboardButtonAlwaysVisible:!0})}),(0,d.jsxs)(_e.s,{gap:"2",children:[q&&(0,d.jsx)(Hr,{href:q}),z&&(0,d.jsx)(Qr,{href:z})]})]}),(0,d.jsx)(oo,{poolsCpuStats:R,memoryStats:k,blobStorageStats:O,tabletStorageStats:M,tenantName:e})]}),(()=>{switch(o){case S.pA.cpu:return(0,d.jsx)(Bl,{tenantName:e,additionalNodesProps:a});case S.pA.storage:return(0,d.jsx)(sc,{tenantName:e,metrics:L});case S.pA.memory:return(0,d.jsx)(Vl,{tenantName:e,memoryUsed:C.MemoryUsed,memoryLimit:C.MemoryLimit,memoryStats:C.MemoryStats});case S.pA.healthcheck:return(0,d.jsx)(Qi,{tenantName:e});default:return(0,d.jsx)(yi,{database:e})}})()]})}const ic=(0,c.cn)("kv-detailed-overview");const oc=function(e){const{type:t,tenantName:a,path:n,additionalTenantProps:s,additionalNodesProps:r}=e,i=a===n;return(0,d.jsx)("div",{className:ic(),children:i?(0,d.jsx)("div",{className:ic("section"),children:(0,d.jsx)(rc,{tenantName:a,additionalTenantProps:s,additionalNodesProps:r})}):(0,d.jsx)(qr,{type:t,path:n,database:a})})},lc={id:S.iJ.overview,title:"Info"},cc={id:S.iJ.schema,title:"Schema"},dc={id:S.iJ.topQueries,title:"Queries"},uc={id:S.iJ.topShards,title:"Top shards"},mc={id:S.iJ.nodes,title:"Nodes"},pc={id:S.iJ.tablets,title:"Tablets"},hc={id:S.iJ.storage,title:"Storage"},vc={id:S.iJ.network,title:"Network"},gc={id:S.iJ.describe,title:"Describe"},yc={id:S.iJ.hotKeys,title:"Hot keys"},xc={id:S.iJ.graph,title:"Graph"},fc={id:S.iJ.consumers,title:"Consumers"},bc={id:S.iJ.partitions,title:"Partitions"},jc={id:S.iJ.topicData,title:"Data"},Tc=[lc,pc,gc],Sc=[lc,pc,gc],wc=[lc,dc,uc,mc,pc,hc,vc,gc,{id:S.iJ.configs,title:"Configs"},{id:S.iJ.operations,title:"Operations"}],Nc=[lc,cc,uc,mc,xc,pc,yc,gc],Ec=[lc,cc,uc,mc,pc,gc],Cc=[lc,uc,mc,gc],Pc=[lc,fc,bc,mc,gc],Ic=[lc,mc,pc,gc],Dc=[lc,fc,bc,jc,mc,pc,gc],_c=[lc,gc],Ac=[lc,cc,gc],Rc=[lc,cc,gc],kc={[Ye.EPathTypeInvalid]:void 0,[Ye.EPathTypeSubDomain]:wc,[Ye.EPathTypeExtSubDomain]:wc,[Ye.EPathTypeColumnStore]:wc,[Ye.EPathTypeTable]:Nc,[Ye.EPathTypeColumnTable]:Ec,[Ye.EPathTypeDir]:Cc,[Ye.EPathTypeTableIndex]:Cc,[Ye.EPathTypeCdcStream]:Pc,[Ye.EPathTypePersQueueGroup]:Dc,[Ye.EPathTypeExternalDataSource]:_c,[Ye.EPathTypeExternalTable]:Ac,[Ye.EPathTypeView]:Rc,[Ye.EPathTypeReplication]:Tc,[Ye.EPathTypeTransfer]:Sc,[Ye.EPathTypeResourcePool]:Cc},Oc={[Ze.EPathSubTypeStreamImpl]:Ic,[Ze.EPathSubTypeSyncIndexImplTable]:void 0,[Ze.EPathSubTypeAsyncIndexImplTable]:void 0,[Ze.EPathSubTypeEmpty]:void 0},Mc=(e,t,a)=>{let n=(t?Oc[t]:void 0)||(e?kc[e]:void 0)||Cc;var s;return!(e=>e===Ye.EPathTypePersQueueGroup)(e)||null!==a&&void 0!==a&&a.hasTopicData?(vt(e)||null!==a&&void 0!==a&&a.isTopLevel)&&(n=wc,null===a||void 0===a||!a.hasFeatureFlags)?n.filter((e=>e.id!==S.iJ.configs)):n:null===(s=n)||void 0===s?void 0:s.filter((e=>e.id!==S.iJ.topicData))},Lc=()=>{const[e]=(0,r.useQueryParams)({database:r.StringParam,schema:r.StringParam,backend:r.StringParam,clusterName:r.StringParam});return n.useCallback(((t,a)=>(0,Pa.YL)({...e,[Pa.vh.diagnosticsTab]:t,...a})),[e])};var qc=a(81240),zc=a(80604);const Fc=g.F.injectEndpoints({endpoints:e=>({getHotKeys:e.query({queryFn:async({path:e,database:t},{signal:a})=>{try{var n;const s=await window.api.viewer.getHotKeys({path:e,database:t,enableSampling:!0},{signal:a});if(Array.isArray(s.hotkeys))return{data:s.hotkeys};await Promise.race([new Promise((e=>{setTimeout(e,5e3)})),new Promise(((e,t)=>{a.addEventListener("abort",t)}))]);return{data:null!==(n=(await window.api.viewer.getHotKeys({path:e,database:t,enableSampling:!1},{signal:a})).hotkeys)&&void 0!==n?n:null}}catch(s){return{error:s}}},providesTags:["All"]})}),overrideExisting:"throw"}),Uc=JSON.parse('{"hot-keys-collecting":"Please wait a little while we are collecting hot keys samples...","no-data":"No information about hot keys","help":"Hot keys contains a list of table primary key values that are accessed most often. Sample is collected upon request to the tab during 5s time interval. Samples column indicates how many requests to the particular key value were registered during collection phase."}'),Qc=(0,he.g4)("ydb-hot-keys",{en:Uc});var $c;function Bc(){return Bc=Object.assign?Object.assign.bind():function(e){for(var t=1;t((e=[])=>[...e.map(((e,t)=>({name:e,header:(0,d.jsxs)("div",{className:Wc("primary-key-column"),children:[(0,d.jsx)(Re.I,{data:Hc,width:12,height:7}),e]}),render:({row:e})=>e.keyValues[t],align:Pt.Ay.RIGHT,sortable:!1}))),{name:Gc,header:"Samples",render:({row:e})=>e.accessSample,align:Pt.Ay.RIGHT,sortable:!1}])(p)),[p]);return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Jc,{}),l||m?(0,d.jsx)("div",{children:Qc("hot-keys-collecting")}):o?(0,d.jsx)(k.o,{error:o}):r?(0,d.jsx)(ce.l,{wrapperClassName:Wc("table"),columns:h,data:r,settings:f.N3,initialSortOrder:{columnId:Gc,order:Pt.Ay.DESCENDING}}):(0,d.jsx)("div",{children:Qc("no-data")})]})}function Jc(){const[e,t]=(0,b.iK)(f.Gj);return e?null:(0,d.jsxs)(zc.Z,{theme:"info",view:"filled",type:"container",className:Wc("help-card"),children:[Qc("help"),(0,d.jsx)(dn.$,{className:Wc("help-card__close-button"),view:"flat",onClick:()=>t(!0),children:(0,d.jsx)(Re.I,{data:qc.A,size:18})})]})}var Kc=a(78524),Yc=a(9252);const Zc=g.F.injectEndpoints({endpoints:e=>({getNetworkInfo:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.viewer.getNetwork({path:e,database:e},{signal:t})}}catch(a){return{error:a}}},providesTags:["All"]})}),overrideExisting:"throw"});var Xc=a(88610),ed=a(29819);const td=(0,c.cn)("node-network");function ad(){}function nd({nodeId:e,connected:t,capacity:a,rack:s,status:r,onClick:i=ad,onMouseEnter:o=ad,onMouseLeave:l=ad,showID:c,isBlurred:u}){const m=n.useRef(null),p=r||function(e=0,t=0){const a=Math.floor(e/t*100);return 100===a?Ai.m.Green:a>=70?Ai.m.Yellow:a>=1?Ai.m.Red:Ai.m.Grey}(t,a);return(0,d.jsx)("div",{ref:m,className:td({[p.toLowerCase()]:!0,id:c,blur:u}),onMouseEnter:()=>{o(m.current,{nodeId:e,connected:t,capacity:a,rack:s},"node")},onMouseLeave:()=>{l()},onClick:()=>i(e),children:c?e:null})}const sd=e=>null===e||void 0===e?void 0:e.reduce(((e,t)=>t.Connected?e+1:e),0);var rd,id,od,ld,cd,dd,ud,md,pd,hd,vd,gd,yd,xd,fd;function bd(){return bd=Object.assign?Object.assign.bind():function(e){for(var t=1;t0?(0,d.jsx)("div",{className:Td("inner"),children:(0,d.jsxs)("div",{className:Td("nodes-row"),children:[(0,d.jsxs)("div",{className:Td("left"),children:[(0,d.jsx)("div",{className:Td("controls-wrapper"),children:(0,d.jsxs)("div",{className:Td("controls"),children:[(0,d.jsx)(Yc.k,{value:r,onChange:e=>{i((0,Xc.$u)(e))},className:Td("problem-filter")}),(0,d.jsx)("div",{className:Td("checkbox-wrapper"),children:(0,d.jsx)(R.S,{onUpdate:()=>{u(!c)},checked:c,children:"ID"})}),(0,d.jsx)("div",{className:Td("checkbox-wrapper"),children:(0,d.jsx)(R.S,{onUpdate:()=>{p(!m)},checked:m,children:"Racks"})})]})}),(0,d.jsx)(wd,{nodes:f,showId:c,showRacks:m,clickedNode:o,onClickNode:l})]}),(0,d.jsx)("div",{className:Td("right"),children:o?(0,d.jsxs)("div",{children:[(0,d.jsxs)("div",{className:Td("label"),children:["Connectivity of node"," ",(0,d.jsx)(N.N_,{className:Td("link"),to:(0,ed.vI)(o.NodeId),children:o.NodeId})," ","to other nodes"]}),(0,d.jsx)("div",{className:Td("nodes-row"),children:(0,d.jsx)(wd,{nodes:j,isRight:!0,showId:c,showRacks:m,clickedNode:o,onClickNode:l})})]}):(0,d.jsxs)("div",{className:Td("placeholder"),children:[(0,d.jsx)("div",{className:Td("placeholder-img"),children:(0,d.jsx)(Re.I,{data:jd,width:221,height:204})}),(0,d.jsx)("div",{className:Td("placeholder-text"),children:"Select node to see its connectivity to other nodes"})]})})]})}):null]})}function wd({nodes:e,isRight:t,showId:a,showRacks:n,clickedNode:s,onClickNode:r}){const i=(0,b.N4)(Xc.yV),o=(0,b.YQ)();let l=0;const c=Object.keys(e).map(((c,u)=>{const m=Nd(e[c],"Rack");return(0,d.jsxs)("div",{className:Td("nodes-container",{right:t}),children:[(0,d.jsxs)("div",{className:Td("nodes-title"),children:[c," nodes"]}),(0,d.jsx)("div",{className:Td("nodes"),children:n?Object.keys(m).map(((e,n)=>(0,d.jsxs)("div",{className:Td("rack-column"),children:[(0,d.jsx)("div",{className:Td("rack-index"),children:"undefined"===e?"?":e}),m[e].map(((e,n)=>{let c,u;return!t&&"Peers"in e&&e.Peers&&(c=Object.keys(e.Peers).length,u=sd(e.Peers)),i===Xc.s$.PROBLEMS&&c!==u||i===Xc.s$.ALL||t?(l++,(0,d.jsx)(nd,{nodeId:e.NodeId,showID:a,rack:e.Rack,status:"ConnectStatus"in e?e.ConnectStatus:void 0,capacity:c,connected:u,onMouseEnter:(...e)=>{o((0,L.DK)(...e))},onMouseLeave:()=>{o((0,L.w7)())},onClick:t?void 0:()=>{r(s&&e.NodeId===s.NodeId?void 0:e)},isBlurred:!t&&s&&s.NodeId!==e.NodeId},n)):null}))]},n))):e[c].map(((e,n)=>{let c,u;const m=e&&"Peers"in e?e.Peers:void 0;return!t&&"Peers"in e&&e.Peers&&(c=e.Peers.length,u=sd(m)),i===Xc.s$.PROBLEMS&&c!==u||i===Xc.s$.ALL||t?(l++,(0,d.jsx)(nd,{nodeId:e.NodeId,showID:a,rack:e.Rack,status:"ConnectStatus"in e?e.ConnectStatus:void 0,capacity:null===m||void 0===m?void 0:m.length,connected:u,onMouseEnter:(...e)=>{o((0,L.DK)(...e))},onMouseLeave:()=>{o((0,L.w7)())},onClick:t?void 0:()=>{r(s&&e.NodeId===s.NodeId?void 0:e)},isBlurred:!t&&s&&s.NodeId!==e.NodeId},n)):null}))})]},u)}));return i===Xc.s$.PROBLEMS&&0===l?(0,d.jsx)(Kc.v,{name:"thumbsUp",width:"200"}):c}function Nd(e,t){return e.reduce(((e,a)=>(e[a[t]]?e[a[t]].push(a):e[a[t]]=[a],e)),{})}const Ed=["NodeId","Host","Connections","NetworkUtilization","SendThroughput","ReceiveThroughput","PingTime","ClockSkew"],Cd=["NodeId"],Pd=["Host","DC","Rack","Uptime","ConnectStatus","NetworkUtilization","PingTime","ClockSkew"];function Id({database:e,path:t,scrollContainerRef:a,additionalNodesProps:n}){const s=(0,D.Pm)(),r=(0,D.WF)(),[i]=(0,b.iK)(f.g5),l=r&&i;return(0,d.jsx)(o.r,{loading:!s,children:(()=>{return l?(0,d.jsx)(oe.G,{path:t,database:e,scrollContainerRef:a,withPeerRoleFilter:!0,additionalNodesProps:n,columns:(s={database:e,getNodeRef:null===n||void 0===n?void 0:n.getNodeRef},[(0,mo._E)(),(0,mo.Nh)(s,{statusForIcon:"ConnectStatus"}),(0,mo.uk)(),(0,mo.OX)(),(0,mo.jl)(),(0,mo.fr)(),(0,mo.kv)(),(0,mo.SH)(),(0,mo.H)(),(0,mo.DH)(),(0,mo.ui)(),(0,mo.wN)(),(0,mo.pt)()].map((e=>({...e,sortable:(0,po.sp)(e.name)})))),defaultColumnsIds:Ed,requiredColumnsIds:Cd,selectedColumnsKey:"networkNodesTableSelectedColumns",groupByParams:Pd}):(0,d.jsx)(Sd,{tenantName:e});var s})()})}var Dd=a(44992),_d=a(24600),Ad=a(47058),Rd=a(69775),kd=a(41775);const Od=JSON.parse('{"lagsPopover.writeLags":"Write lags statistics (time format dd hh:mm:ss)","lagsPopover.readLags":"Read lags statistics (time format dd hh:mm:ss)","headers.unread":"End offset - Last read offset","headers.uncommited":"End offset - Committed offset","controls.consumerSelector":"Consumer:","controls.consumerSelector.emptyOption":"No consumer","controls.partitionSearch":"Partition ID","controls.generalSearch":"Host, Host ID, Reader, Read Session ID","table.emptyDataMessage":"No partitions match the current search","noConsumersMessage.topic":"This topic has no consumers","noConsumersMessage.stream":"This changefeed has no consumers"}'),Md=JSON.parse('{"lagsPopover.writeLags":"\u0421\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0430 \u043b\u0430\u0433\u043e\u0432 \u0437\u0430\u043f\u0438\u0441\u0438 (\u0444\u043e\u0440\u043c\u0430\u0442 \u0432\u0440\u0435\u043c\u0435\u043d\u0438 \u0434\u0434 \u0447\u0447:\u043c\u043c:\u0441\u0441)","lagsPopover.readLags":"\u0421\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0430 \u043b\u0430\u0433\u043e\u0432 \u0447\u0442\u0435\u043d\u0438\u044f (\u0444\u043e\u0440\u043c\u0430\u0442 \u0432\u0440\u0435\u043c\u0435\u043d\u0438 \u0434\u0434 \u0447\u0447:\u043c\u043c:\u0441\u0441)","headers.unread":"End offset - Last read offset","headers.uncommited":"End offset - Committed offset","controls.consumerSelector":"\u0427\u0438\u0442\u0430\u0442\u0435\u043b\u044c:","controls.consumerSelector.emptyOption":"\u041d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u044f","controls.partitionSearch":"Partition ID","controls.generalSearch":"Host, Host ID, Reader, Read Session ID","table.emptyDataMessage":"\u041f\u043e \u0437\u0430\u0434\u0430\u043d\u043d\u043e\u043c\u0443 \u043f\u043e\u0438\u0441\u043a\u0443 \u043d\u0435\u0442 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439","noConsumersMessage.topic":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0442\u043e\u043f\u0438\u043a\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","noConsumersMessage.stream":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0441\u0442\u0440\u0438\u043c\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439"}'),Ld=(0,he.g4)("ydb-diagnostics-partitions",{ru:Md,en:Od}),qd={PARTITION_ID:"partitionId",STORE_SIZE:"storeSize",WRITE_SPEED:"writeSpeed",READ_SPEED:"readSpeed",WRITE_LAGS:"writeLags",READ_LAGS:"readLags",UNCOMMITED_MESSAGES:"uncommitedMessages",UNREAD_MESSAGES:"unreadMessages",START_OFFSET:"startOffset",END_OFFSET:"endOffset",COMMITED_OFFSET:"commitedOffset",READ_SESSION_ID:"readSessionId",READER_NAME:"readerName",PARTITION_HOST:"partitionHost",CONNECTION_HOST:"connectionHost"},zd={[qd.PARTITION_ID]:"Partition ID",[qd.STORE_SIZE]:"Store size",[qd.WRITE_SPEED]:"Write speed",[qd.READ_SPEED]:"Read speed",[qd.WRITE_LAGS]:"Write lags, duration",[qd.READ_LAGS]:"Read lags, duration",[qd.UNCOMMITED_MESSAGES]:"Uncommited messages",[qd.UNREAD_MESSAGES]:"Unread messages",[qd.START_OFFSET]:"Start offset",[qd.END_OFFSET]:"End offset",[qd.COMMITED_OFFSET]:"Commited offset",[qd.READ_SESSION_ID]:"Read session ID",[qd.READER_NAME]:"Reader name",[qd.PARTITION_HOST]:"Partition host",[qd.CONNECTION_HOST]:"Connection host"},Fd="partitionWriteLag",Ud="partitionWriteIdleTime",Qd={[Fd]:"write lag",[Ud]:"write idle time"},$d="consumerWriteLag",Bd="consumerReadLag",Hd="consumerReadIdleTime",Wd={[$d]:"write lag",[Bd]:"read lag",[Hd]:"read idle time"},Gd=[qd.PARTITION_ID,qd.STORE_SIZE,qd.WRITE_SPEED,qd.WRITE_LAGS,qd.START_OFFSET,qd.END_OFFSET,qd.PARTITION_HOST],Vd=Object.values(qd),Jd=({consumers:e,selectedConsumer:t,onSelectedConsumerChange:a,selectDisabled:s,partitions:r,onSearchChange:i,hiddenColumns:o,onHiddenColumnsChange:l,initialColumnsIds:c})=>{const[u,m]=n.useState(""),[p,h]=n.useState("");n.useEffect((()=>{if(!r)return;const e=new RegExp(la()(p),"i"),t=new RegExp(la()(u),"i"),a=r.filter((a=>{const{partitionId:n,readerName:s,readSessionId:r,partitionNodeId:i,connectionNodeId:o,partitionHost:l,connectionHost:c}=a,d=e.test(String(n)),u=[s,r,i,o,l,c].filter(Boolean).map(String),m=0===u.length||u.some((e=>t.test(e)));return d&&m}));i(a)}),[p,u,r,i]);const v=n.useMemo((()=>{const t=e&&e.length?e.map((e=>({value:e,content:e}))):[];return[{value:"",content:Ld("controls.consumerSelector.emptyOption")},...t]}),[e]),g=n.useMemo((()=>{const e=[];for(const t of c){const a=t===qd.PARTITION_ID,n={title:zd[t],selected:Boolean(!o.includes(t)),id:t,required:a,sticky:a?"start":void 0};a?e.unshift(n):e.push(n)}return e}),[c,o]),y=e=>(0,d.jsx)("div",{className:lu("select-option",{empty:""===e.value}),children:e.content});return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(A.l,{className:lu("consumer-select"),label:Ld("controls.consumerSelector"),options:v,value:[t||""],onUpdate:e=>{a(e[0]||void 0)},filterable:e&&e.length>5,disabled:s||!e||!e.length,renderOption:y,renderSelectedOption:y}),(0,d.jsx)(kd.v,{onChange:e=>{h(e)},placeholder:Ld("controls.partitionSearch"),className:lu("search",{partition:!0}),value:p}),(0,d.jsx)(kd.v,{onChange:e=>{m(e)},placeholder:Ld("controls.generalSearch"),className:lu("search",{general:!0}),value:u}),(0,d.jsx)(Rd.O,{popupWidth:242,items:g,showStatus:!0,onUpdate:e=>{const t=[...o];e.forEach((e=>{e.selected||o.includes(e.id)?e.selected&&o.includes(e.id)&&t.splice(o.indexOf(e.id)):t.push(e.id)})),l(t)},sortable:!1},"TableColumnSetup")]})},Kd=(0,c.cn)("ydb-multiline-table-header");function Yd({title:e}){return e?(0,d.jsx)("div",{className:Kd(),children:e}):null}const Zd=(0,c.cn)("ydb-diagnostics-partitions-columns-header"),Xd=()=>(0,d.jsx)("div",{className:Zd("read-session"),children:zd[qd.READ_SESSION_ID]}),eu=()=>(0,d.jsx)(Da,{className:Zd("lags"),text:zd[qd.WRITE_LAGS],popoverContent:(0,d.jsx)(Ba,{text:Ld("lagsPopover.writeLags"),type:"write"})}),tu=()=>(0,d.jsx)(Da,{className:Zd("lags"),text:zd[qd.READ_LAGS],popoverContent:(0,d.jsx)(Ba,{text:Ld("lagsPopover.readLags"),type:"read"})}),au=()=>(0,d.jsx)(Da,{className:Zd("messages"),text:zd[qd.UNREAD_MESSAGES],popoverContent:(0,d.jsx)("div",{className:Zd("messages-popover-content"),children:Ld("headers.unread")})}),nu=()=>(0,d.jsx)(Da,{className:Zd("messages"),text:zd[qd.UNCOMMITED_MESSAGES],popoverContent:(0,d.jsx)("div",{className:Zd("messages-popover-content"),children:Ld("headers.uncommited")})}),su=(0,c.cn)("ydb-diagnostics-partitions-columns"),ru=[{name:qd.PARTITION_ID,header:(0,d.jsx)(Yd,{title:zd[qd.PARTITION_ID]}),sortAccessor:e=>(0,Er.kf)(e.partitionId)&&Number(e.partitionId),align:Pt.Ay.LEFT,render:({row:e})=>(0,d.jsx)(ou,{id:String(e.partitionId)})},{name:qd.STORE_SIZE,header:(0,d.jsx)(Yd,{title:zd[qd.STORE_SIZE]}),sortAccessor:e=>(0,Er.kf)(e.storeSize)&&Number(e.storeSize),align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.z3)(e.storeSize)},{name:qd.WRITE_SPEED,header:zd[qd.WRITE_SPEED],align:Pt.Ay.LEFT,resizeMinWidth:140,sortAccessor:e=>e.writeSpeed.perMinute,render:({row:e})=>(0,d.jsx)(Ta,{data:e.writeSpeed})},{name:qd.READ_SPEED,header:zd[qd.READ_SPEED],align:Pt.Ay.LEFT,resizeMinWidth:140,sortAccessor:e=>{var t;return null===(t=e.readSpeed)||void 0===t?void 0:t.perMinute},render:({row:e})=>(0,d.jsx)(Ta,{data:e.readSpeed})},{name:qd.WRITE_LAGS,header:(0,d.jsx)(eu,{}),className:su("lags-header"),sub:[{name:Fd,header:Qd[Fd],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.partitionWriteLag)},{name:Ud,header:Qd[Ud],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.partitionWriteIdleTime)}]},{name:qd.READ_LAGS,header:(0,d.jsx)(tu,{}),className:su("lags-header"),sub:[{name:$d,header:Wd[$d],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.consumerWriteLag)},{name:Bd,header:Wd[Bd],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.consumerReadLag)},{name:Hd,header:Wd[Hd],align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.lr)(e.consumerReadIdleTime)}]},{name:qd.UNCOMMITED_MESSAGES,header:(0,d.jsx)(nu,{}),align:Pt.Ay.RIGHT,render:({row:e})=>e.uncommitedMessages},{name:qd.UNREAD_MESSAGES,header:(0,d.jsx)(au,{}),align:Pt.Ay.RIGHT,render:({row:e})=>e.unreadMessages},{name:qd.START_OFFSET,header:(0,d.jsx)(Yd,{title:zd[qd.START_OFFSET]}),sortAccessor:e=>(0,Er.kf)(e.startOffset)&&Number(e.startOffset),align:Pt.Ay.RIGHT,render:({row:e})=>e.startOffset},{name:qd.END_OFFSET,header:(0,d.jsx)(Yd,{title:zd[qd.END_OFFSET]}),sortAccessor:e=>(0,Er.kf)(e.endOffset)&&Number(e.endOffset),align:Pt.Ay.RIGHT,render:({row:e})=>e.endOffset},{name:qd.COMMITED_OFFSET,header:(0,d.jsx)(Yd,{title:zd[qd.COMMITED_OFFSET]}),sortAccessor:e=>(0,Er.kf)(e.commitedOffset)&&Number(e.commitedOffset),align:Pt.Ay.RIGHT,render:({row:e})=>e.commitedOffset},{name:qd.READ_SESSION_ID,header:(0,d.jsx)(Xd,{}),align:Pt.Ay.LEFT,width:150,render:({row:e})=>e.readSessionId?(0,d.jsx)(_s.c,{name:e.readSessionId,showStatus:!1,hasClipboardButton:!0}):"\u2013"},{name:qd.READER_NAME,header:(0,d.jsx)(Yd,{title:zd[qd.READER_NAME]}),align:Pt.Ay.LEFT,width:150,render:({row:e})=>e.readerName?(0,d.jsx)(_s.c,{name:e.readerName,showStatus:!1,hasClipboardButton:!0}):"\u2013"},{name:qd.PARTITION_HOST,header:(0,d.jsx)(Yd,{title:zd[qd.PARTITION_HOST]}),align:Pt.Ay.LEFT,width:200,render:({row:e})=>e.partitionNodeId&&e.partitionHost?(0,d.jsx)(_s.c,{name:e.partitionHost,path:(0,ed.vI)(e.partitionNodeId),showStatus:!1,hasClipboardButton:!0}):"\u2013"},{name:qd.CONNECTION_HOST,header:(0,d.jsx)(Yd,{title:zd[qd.CONNECTION_HOST]}),align:Pt.Ay.LEFT,width:200,render:({row:e})=>e.connectionNodeId&&e.connectionHost?(0,d.jsx)(_s.c,{name:e.connectionHost,path:(0,ed.vI)(e.connectionNodeId),showStatus:!1,hasClipboardButton:!0}):"\u2013"}],iu=ru.filter((e=>Gd.includes(e.name)));function ou({id:e}){const t=Lc(),a=(0,D._p)();return(0,d.jsx)(_s.c,{name:e,path:a?t(S.iJ.topicData,{selectedPartition:e}):void 0,showStatus:!1})}const lu=(0,c.cn)("ydb-diagnostics-partitions"),cu=({path:e,database:t})=>{const a=(0,b.YQ)(),[s,r]=n.useState([]),i=(0,b.N4)((a=>va(a,e,t))),[o]=(0,b.Nt)(),{selectedConsumer:l}=(0,b.N4)((e=>e.partitions)),{currentData:c,isFetching:u,error:m}=ua.useGetTopicQuery({path:e,database:t}),p=u&&void 0===c,{currentData:h,isFetching:v,error:g}=_d.m.useGetNodesListQuery(void 0),y=v&&void 0===h,x=(0,b.N4)(_d.K),[j,T]=(0,b.iK)(f.bs),[S,w]=(e=>{const[t,a]=n.useState([]),[s,r]=n.useState([]);return n.useEffect((()=>{e?(a(ru),r(Vd)):(a(iu),r(Gd))}),[e]),[t,s]})(l),N=p?Dd.hT:{path:e,database:t,consumerName:l},{currentData:E,isFetching:C,error:P}=Ad.aD.useGetPartitionsQuery(N,{pollingInterval:o}),I=C&&void 0===E,D=E,_=n.useMemo((()=>((e=[],t)=>null===e||void 0===e?void 0:e.map((e=>{var a,n;const s=e.partitionNodeId&&t?null===(a=t.get(e.partitionNodeId))||void 0===a?void 0:a.Host:void 0,r=e.connectionNodeId&&t?null===(n=t.get(e.connectionNodeId))||void 0===n?void 0:n.Host:void 0;return{...e,partitionHost:s,connectionHost:r}})))(D,x)),[D,x]);n.useEffect((()=>{const e=!p&&!i,t=l&&i&&!i.includes(l);(e||t)&&a((0,Ad.WD)(void 0))}),[a,p,l,i]);const A=n.useMemo((()=>S.filter((e=>!j.includes(e.name)))),[S,j]),R=e=>{T(e)},O=e=>{a((0,Ad.WD)(e))},M=p||y||I,L=g||m||P;return(0,d.jsxs)(de.L,{className:lu(),children:[(0,d.jsx)(de.L.Controls,{children:(0,d.jsx)(Jd,{consumers:i,selectedConsumer:l,onSelectedConsumerChange:O,selectDisabled:Boolean(L)||M,partitions:_,onSearchChange:r,hiddenColumns:j,onHiddenColumnsChange:R,initialColumnsIds:w})}),(0,d.jsxs)(de.L.Table,{children:[L?(0,d.jsx)(k.o,{error:L}):null,E?M?(0,d.jsx)(Ge.Q,{className:lu("loader")}):(0,d.jsx)(ce.l,{columnsWidthLSKey:"partitionsColumnsWidth",wrapperClassName:lu("table"),data:s,columns:A,settings:f.N3,emptyDataMessage:Ld("table.emptyDataMessage")}):null]})]})};var du=a(44433),uu=a(13847),mu=a(80247),pu=a(55929),hu=a(46700);const vu=JSON.parse('{"description_copy":"Copy link to clipboard","description_copied":"Copied to clipboard"}'),gu=(0,he.g4)("ydb-copy-link-button",{en:vu}),yu=(0,c.cn)("ydb-copy-link-button"),xu=e=>{const{size:t="m",hasTooltip:a=!0,status:n,closeDelay:s,title:r,...i}=e,o=null!==r&&void 0!==r?r:gu("description_copy");return(0,d.jsx)(Ae.m,{title:"success"===n?gu("description_copied"):o,disabled:!a,closeDelay:s,children:(0,d.jsx)(dn.$,{view:"flat",size:t,...i,children:(0,d.jsx)(dn.$.Icon,{className:yu("icon"),children:(0,d.jsx)(Re.I,{data:pu.A,size:16})})})})};function fu(e){const{text:t,...a}=e,s=n.useRef(),[r,i]=n.useState(void 0),[o,l]=n.useState(!1),c=1200;n.useEffect((()=>window.clearTimeout(s.current)),[]);const u=n.useCallback((()=>{l(!1),i(c),window.clearTimeout(s.current),s.current=window.setTimeout((()=>{l(!0)}),1e3)}),[c]);return(0,d.jsx)(hu.$,{text:t,timeout:c,onCopy:u,children:e=>(0,d.jsx)(xu,{...a,closeDelay:r,hasTooltip:!o,status:e})})}const bu=(0,c.cn)("ydb-drawer"),ju=({isVisible:e,onClose:t,children:a,drawerId:s="drawer",storageKey:r="drawer-width",defaultWidth:i,direction:o="right",className:l,detectClickOutside:c=!1,isPercentageWidth:u})=>{const[m,p]=n.useState((()=>{const e=localStorage.getItem(r);return(0,Er.kf)(e)?Number(e):i})),h=n.useRef(null),{containerWidth:v}=(()=>{const e=n.useContext(P);if(void 0===e)throw Error("useDrawerContext must be used within a DrawerContextProvider");return e})(),g=n.useMemo((()=>u&&v>0?Math.round(v*(m||60)/100):m||600),[v,u,m]);n.useEffect((()=>{if(!c)return;const a=a=>{!a._capturedInsideDrawer&&a.isTrusted&&e&&h.current&&!h.current.contains(a.target)&&t()};return document.addEventListener("click",a),()=>{document.removeEventListener("click",a)}}),[e,t,c]);return(0,d.jsx)(mu._,{onEscape:t,onVeilClick:t,hideVeil:!0,className:bu("container",l),children:(0,d.jsx)(mu.l,{id:s,visible:e,resizable:!0,maxResizeWidth:v,width:u?g:m,onResize:e=>{if(u&&v>0){const t=Math.round(e/v*100);p(t),localStorage.setItem(r,t.toString())}else p(e),localStorage.setItem(r,e.toString())},direction:o,className:bu("item"),ref:c?h:void 0,children:(0,d.jsx)("div",{className:bu("click-handler"),onClickCapture:e=>{e.nativeEvent._capturedInsideDrawer=!0},children:a})})})},Tu=({children:e,renderDrawerContent:t,isDrawerVisible:a,onCloseDrawer:s,drawerId:r,storageKey:i,defaultWidth:o,direction:l,className:c,detectClickOutside:u,isPercentageWidth:m,drawerControls:p=[],title:h,headerClassName:v})=>{n.useEffect((()=>()=>{s()}),[s]);return(0,d.jsxs)(n.Fragment,{children:[e,(0,d.jsx)(ju,{isVisible:a,onClose:s,drawerId:r,storageKey:i,defaultWidth:o,direction:l,className:c,detectClickOutside:u,isPercentageWidth:m,children:a?(0,d.jsxs)("div",{className:bu("content-wrapper"),children:[(()=>{const e=[];for(const t of p)switch(t.type){case"close":e.push((0,d.jsx)(Ae.m,{title:"Close",children:(0,d.jsx)(dn.$,{view:"flat",onClick:s,children:(0,d.jsx)(Re.I,{data:qc.A,size:16})})},"close"));break;case"copyLink":e.push((0,d.jsx)(fu,{text:t.link},"copyLink"));break;case"custom":e.push((0,d.jsx)(n.Fragment,{children:t.node},t.key))}return(0,d.jsxs)(_e.s,{justifyContent:"space-between",alignItems:"center",className:bu("header-wrapper",v),children:[(0,d.jsx)(De.E,{variant:"subheader-2",children:h}),(0,d.jsx)(_e.s,{className:bu("controls"),children:e})]})})(),t()]}):null})]})};var Su=a(43951);const wu={...Xo,disableSortReset:!0,externalSort:!0};function Nu(e){const t=[];var a,n;(e.QueryText&&t.push({label:tl("query-hash"),value:Zo(String(e.QueryText))}),void 0!==e.CPUTimeUs)&&t.push({label:tl("cpu-time"),value:(0,ze.Xo)((0,ze.Jc)(null!==(a=e.CPUTimeUs)&&void 0!==a?a:void 0))});void 0!==e.Duration&&t.push({label:tl("duration"),value:(0,ze.Xo)((0,ze.Jc)(null!==(n=e.Duration)&&void 0!==n?n:void 0))});return void 0!==e.ReadBytes&&t.push({label:tl("read-bytes"),value:(0,q.ZV)(e.ReadBytes)}),void 0!==e.RequestUnits&&t.push({label:tl("request-units"),value:(0,q.ZV)(e.RequestUnits)}),e.EndTime&&t.push({label:tl("end-time"),value:(0,q.r6)(new Date(e.EndTime).getTime())}),void 0!==e.ReadRows&&t.push({label:tl("read-rows"),value:(0,q.ZV)(e.ReadRows)}),e.UserSID&&t.push({label:tl("user"),value:e.UserSID}),e.ApplicationName&&t.push({label:tl("application"),value:e.ApplicationName}),e.QueryStartAt&&t.push({label:tl("start-time"),value:(0,q.r6)(new Date(e.QueryStartAt).getTime())}),t}const Eu=JSON.parse('{"no-data":"No data","filter.text.placeholder":"Search by query text or userSID...","mode_top":"Top","mode_running":"Running","timeframe_hour":"Per hour","timeframe_minute":"Per minute","query-details.title":"Query","query-details.open-in-editor":"Open in Editor","query-details.close":"Close","query-details.query.title":"Query Text","query-details.not-found.title":"Not found","query-details.not-found.description":"This query no longer exists"}'),Cu=(0,he.g4)("ydb-diagnostics-top-queries",{en:Eu});var Pu;function Iu(){return Iu=Object.assign?Object.assign.bind():function(e){for(var t=1;t(0,d.jsxs)(_e.s,{justifyContent:"center",alignItems:"center",direction:"column",className:_u("not-found-container"),children:[(0,d.jsx)(Re.I,{data:Du,size:100}),(0,d.jsx)(De.E,{variant:"subheader-2",className:_u("not-found-title"),children:Cu("query-details.not-found.title")}),(0,d.jsx)(De.E,{variant:"body-1",color:"complementary",className:_u("not-found-description"),children:Cu("query-details.not-found.description")}),(0,d.jsx)(dn.$,{size:"m",view:"normal",className:_u("not-found-close"),onClick:e,children:Cu("query-details.close")})]});var Ru=a(968);const ku=(0,c.cn)("ydb-query-details"),Ou=({queryText:e,infoItems:t,onOpenInEditor:a})=>(0,d.jsx)(_e.s,{direction:"column",className:ku(),children:(0,d.jsxs)(_e.s,{direction:"column",className:ku("content"),children:[(0,d.jsx)(us.z_,{info:t}),(0,d.jsxs)("div",{className:ku("query-content"),children:[(0,d.jsxs)("div",{className:ku("query-header"),children:[(0,d.jsx)("div",{className:ku("query-title"),children:Cu("query-details.query.title")}),(0,d.jsxs)(dn.$,{view:"flat-secondary",size:"m",onClick:a,className:ku("editor-button"),children:[(0,d.jsx)(Re.I,{data:Ru.A,size:16}),Cu("query-details.open-in-editor")]})]}),(0,d.jsx)(Ws.YDBSyntaxHighlighter,{language:"yql",text:e,withClipboardButton:{alwaysVisible:!0,withLabel:!1}})]})]})}),Mu=({row:e,onClose:t})=>{const a=(0,b.YQ)(),s=(0,zs.zy)(),r=(0,zs.W6)(),i=n.useCallback((()=>{if(e){const t=e.QueryText;a((0,So.iZ)({input:t})),a((0,So.Xb)(!1));const n=(0,U.mA)(s),i=(0,Pa.YL)({...n,[S.Dt]:S.Dg.query,[Pa.vh.queryTab]:S.tQ.newQuery});r.push(i)}}),[a,r,s,e]);return e?(0,d.jsx)(Ou,{queryText:e.QueryText,infoItems:Nu(e),onOpenInEditor:i}):(0,d.jsx)(Au,{onClose:t})},Lu={encode:e=>{if(void 0!==e&&null!==e&&Array.isArray(e))return encodeURIComponent(JSON.stringify(e))},decode:e=>{if("string"!==typeof e||!e)return[];try{return JSON.parse(decodeURIComponent(e))}catch{return[]}}};function qu(e){const{paramName:t,schema:a,defaultSort:s}=e,[i,o]=(0,r.useQueryParam)(t,Lu);return{sortParam:n.useMemo((()=>{if(!i||!Array.isArray(i)||0===i.length)return[s];const e=i.filter((e=>{try{return a.parse(e.columnId),!0}catch{return!1}}));return e.length?e:[s]}),[i,a,s]),updateSortParam:n.useCallback((e=>{o(e||[],"replaceIn")}),[o])}}const zu=Qe.z.enum([ml,ll,pl]).catch(ml),Fu={columnId:ml,order:Pt.Ay.DESCENDING};const Uu=(0,c.cn)("kv-top-queries"),Qu=({tenantName:e,renderQueryModeControl:t,handleTextSearchUpdate:a})=>{var s,r;const[i]=(0,b.Nt)(),o=(0,b.N4)((e=>e.executeTopQueries)),[l,c]=n.useState(void 0),u=n.useMemo((()=>[Al,Dl,kl,El,Ml].map((e=>{return{...e,sortable:(t=e.name,Boolean(Sl(t)))};var t}))),[]),{columnsToShow:m,columnsToSelect:p,setColumns:h}=(0,Su.K)(u,"runningQueriesSelectedColumns",fl,yl,xl),{tableSort:v,handleTableSort:g,backendSort:y}=function(){var e,t;const{sortParam:a,updateSortParam:s}=qu({paramName:"runningSort",schema:zu,defaultSort:Fu}),[r,i]=(0,b.GY)({initialSortColumn:(null===a||void 0===a||null===(e=a[0])||void 0===e?void 0:e.columnId)||Fu.columnId,initialSortOrder:(null===a||void 0===a||null===(t=a[0])||void 0===t?void 0:t.order)||Fu.order,multiple:!0,onSort:s});return{tableSort:r,handleTableSort:i,backendSort:n.useMemo((()=>(0,b.JN)(r,Sl)),[r])}}(),{currentData:x,isFetching:f,isLoading:j,error:T}=To.Ke.useGetRunningQueriesQuery({database:e,filters:o,sortOrder:y},{pollingInterval:i}),S=null===x||void 0===x||null===(s=x.resultSets)||void 0===s||null===(r=s[0])||void 0===r?void 0:r.result,w=void 0!==l,N=n.useCallback((()=>{c(void 0)}),[c]),E=n.useCallback((()=>(0,d.jsx)(Mu,{row:l,onClose:N})),[l,N]),C=n.useCallback(((e,t,a)=>{null===a||void 0===a||a.stopPropagation(),c(e)}),[c]),P=n.useRef(null);n.useEffect((()=>{var e;w&&(null===(e=P.current)||void 0===e||e.blur())}),[w]);const I=n.useMemo((()=>[{type:"close"}]),[]);return(0,d.jsx)(Tu,{isDrawerVisible:w,onCloseDrawer:N,renderDrawerContent:E,drawerId:"running-query-details",storageKey:"running-queries-drawer-width",detectClickOutside:!0,isPercentageWidth:!0,title:Cu("query-details.title"),drawerControls:I,children:(0,d.jsxs)(de.L,{children:[(0,d.jsxs)(de.L.Controls,{children:[t(),(0,d.jsx)(pe.v,{value:o.text,onChange:a,placeholder:Cu("filter.text.placeholder"),className:Uu("search"),inputRef:P}),(0,d.jsx)(Rd.O,{popupWidth:200,items:p,showStatus:!0,onUpdate:h,sortable:!1})]}),T?(0,d.jsx)(k.o,{error:(0,Ve.Cb)(T)}):null,(0,d.jsx)(de.L.Table,{loading:j,children:(0,d.jsx)(ce.l,{emptyDataMessage:Cu("no-data"),columnsWidthLSKey:"runningQueriesColumnsWidth",columns:m,data:S||[],loading:f&&void 0===x,settings:wu,onRowClick:C,rowClassName:e=>Uu("row",{active:(0,uu.isEqual)(e,l)}),sortOrder:v,onSort:g})})]})})};var $u=a(33167);const Bu=JSON.parse('{"date-format":"MM/DD/YYYY","date-time-format":"MM/DD/YYYY HH:mm"}'),Hu=JSON.parse('{"date-format":"DD.MM.YYYY","date-time-format":"DD.MM.YYYY HH:mm"}'),Wu=(0,he.g4)("ydb-date-range",{ru:Hu,en:Bu});function Gu(e){var t,a,n,s;return"relative"===(null===e||void 0===e||null===(t=e.start)||void 0===t?void 0:t.type)&&"relative"===(null===e||void 0===e||null===(a=e.end)||void 0===a?void 0:a.type)?"s":"relative"===(null===e||void 0===e||null===(n=e.start)||void 0===n?void 0:n.type)||"relative"===(null===e||void 0===e||null===(s=e.end)||void 0===s?void 0:s.type)?"m":"l"}const Vu=(0,c.cn)("date-range"),Ju=({from:e,to:t,className:a,defaultValue:s,onChange:r})=>{const i=n.useCallback((e=>null===r||void 0===r?void 0:r(function(e){var t,a,n,s,r,i;return{from:"relative"===(null===e||void 0===e||null===(t=e.start)||void 0===t?void 0:t.type)?e.start.value.toString():String(null===(a=(0,Ce.bQ)(null===e||void 0===e||null===(n=e.start)||void 0===n?void 0:n.value))||void 0===a?void 0:a.valueOf()),to:"relative"===(null===e||void 0===e||null===(s=e.end)||void 0===s?void 0:s.type)?e.end.value.toString():String(null===(r=(0,Ce.bQ)(null===e||void 0===e||null===(i=e.end)||void 0===i?void 0:i.value))||void 0===r?void 0:r.valueOf())}}(e))),[r]),o=n.useMemo((()=>{if(e||t)return function(e){var t,a;const n=(0,Ce.eP)(null!==(t=e.from)&&void 0!==t?t:""),s=(0,Ce.eP)(null!==(a=e.to)&&void 0!==a?a:"");return{start:e.from?{type:n?"relative":"absolute",value:n?e.from:(0,Ce.bQ)(Number(e.from))}:null,end:e.to?{type:s?"relative":"absolute",value:s?e.to:(0,Ce.bQ)(Number(e.to))}:null}}({from:e,to:t})}),[e,t]),l=Intl.DateTimeFormat().resolvedOptions().timeZone,c=o||s;return(0,d.jsx)("div",{className:Vu(null,a),children:(0,d.jsx)($u.k,{withPresets:!0,className:Vu("range-input",{[Gu(c)]:!0}),timeZone:l,value:c,allowNullableValues:!0,size:"m",format:Wu("date-time-format"),onUpdate:i,placeholder:`${Wu("date-time-format")} - ${Wu("date-time-format")}`,withApplyButton:!0})})},Ku={hour:"hour",minute:"minute"},Yu=[{value:Ku.hour,content:Cu("timeframe_hour")},{value:Ku.minute,content:Cu("timeframe_minute")}],Zu={start:{value:"now-6h",type:"relative"},end:{value:"now",type:"relative"}};function Xu(e){const t=Zo(String(e.QueryText));return{rank:String(e.Rank),intervalEnd:String(e.IntervalEnd),endTime:String(e.EndTime),queryHash:t}}const em=Qe.z.enum([nl,ul,il,ol,sl]).catch(nl),tm={columnId:nl,order:Pt.Ay.DESCENDING};const am=(0,c.cn)("kv-top-queries"),nm=({tenantName:e,timeFrame:t,renderQueryModeControl:a,handleTimeFrameChange:s,handleDateRangeChange:i,handleTextSearchUpdate:o})=>{var l,c;const[u]=(0,b.Nt)(),m=(0,b.N4)((e=>e.executeTopQueries)),[p,h]=n.useState(void 0),v=n.useMemo((()=>[Al,Nl,Rl,Il,Ol,El,Cl,Pl,Dl].map((e=>{return{...e,sortable:(t=e.name,Boolean(Tl(t))),defaultOrder:Pt.Ay.DESCENDING};var t}))),[]),{columnsToShow:g,columnsToSelect:y,setColumns:x}=(0,Su.K)(v,"topQueriesSelectedColumns",fl,vl,gl),{tableSort:f,handleTableSort:j,backendSort:T}=function(){var e,t;const{sortParam:a,updateSortParam:s}=qu({paramName:"topSort",schema:em,defaultSort:tm}),[r,i]=(0,b.GY)({initialSortColumn:(null===a||void 0===a||null===(e=a[0])||void 0===e?void 0:e.columnId)||tm.columnId,initialSortOrder:(null===a||void 0===a||null===(t=a[0])||void 0===t?void 0:t.order)||tm.order,multiple:!0,fixedOrderType:Pt.Ay.DESCENDING,onSort:s});return{tableSort:r,handleTableSort:i,backendSort:n.useMemo((()=>(0,b.JN)(r,Tl)),[r])}}(),{currentData:S,isFetching:w,isLoading:N,error:E}=To.Ke.useGetTopQueriesQuery({database:e,filters:m,sortOrder:T,timeFrame:t},{pollingInterval:u}),C=null===S||void 0===S||null===(l=S.resultSets)||void 0===l||null===(c=l[0])||void 0===c?void 0:c.result;!function(e,t){const[a,s]=(0,r.useQueryParams)({selectedRow:r.StringParam});n.useEffect((()=>{if(t&&a.selectedRow){const n=JSON.parse(decodeURIComponent(a.selectedRow)),r=t.find((e=>{const t=Xu(e);return t.rank===n.rank&&t.intervalEnd===n.intervalEnd&&t.endTime===n.endTime&&n.queryHash===t.queryHash}));e(r||null),s({selectedRow:void 0})}}),[a.selectedRow,s,t,e])}(h,C);const P=n.useCallback((()=>{h(void 0)}),[h]),I=void 0!==p,D=n.useCallback((()=>p?function(e){const t=Xu(e),a=new URL(window.location.href),n=new URLSearchParams(a.search);return n.set("selectedRow",encodeURIComponent(JSON.stringify({rank:t.rank||void 0,intervalEnd:t.intervalEnd||void 0,endTime:t.endTime||void 0,queryHash:t.queryHash||void 0}))),a.search=n.toString(),a.toString()}(p):""),[p]),_=n.useCallback((()=>(0,d.jsx)(Mu,{row:p,onClose:P})),[p,P]),R=n.useCallback(((e,t,a)=>{null===a||void 0===a||a.stopPropagation(),h(e)}),[h]),O=n.useRef(null);n.useEffect((()=>{var e;I&&(null===(e=O.current)||void 0===e||e.blur())}),[I]);const M=n.useMemo((()=>[{type:"copyLink",link:D()},{type:"close"}]),[D]);return(0,d.jsx)(Tu,{isDrawerVisible:I,onCloseDrawer:P,renderDrawerContent:_,drawerId:"query-details",storageKey:"kv-top-queries-drawer-width",detectClickOutside:!0,isPercentageWidth:!0,title:Cu("query-details.title"),drawerControls:M,children:(0,d.jsxs)(de.L,{children:[(0,d.jsxs)(de.L.Controls,{children:[a(),(0,d.jsx)(A.l,{options:Yu,value:[t],onUpdate:s}),(0,d.jsx)(Ju,{from:m.from,to:m.to,onChange:i,defaultValue:Zu}),(0,d.jsx)(pe.v,{value:m.text,inputRef:O,onChange:o,placeholder:Cu("filter.text.placeholder"),className:am("search")}),(0,d.jsx)(Rd.O,{popupWidth:200,items:y,showStatus:!0,onUpdate:x,sortable:!1})]}),E?(0,d.jsx)(k.o,{error:(0,Ve.Cb)(E)}):null,(0,d.jsx)(de.L.Table,{loading:N,children:(0,d.jsx)(ce.l,{emptyDataMessage:Cu("no-data"),columnsWidthLSKey:al,columns:g,data:C||[],loading:w&&void 0===S,settings:wu,onRowClick:R,rowClassName:e=>am("row",{active:(0,uu.isEqual)(e,p)}),sortOrder:f,onSort:j})})]})})},sm={top:"top",running:"running"},rm=[{value:sm.top,get content(){return Cu("mode_top")}},{value:sm.running,get content(){return Cu("mode_running")}}],im=Qe.z.nativeEnum(sm).catch(sm.top),om=Qe.z.nativeEnum(Ku).catch(Ku.hour),lm=({tenantName:e})=>{const t=(0,b.YQ)(),[a=sm.top,s]=(0,r.useQueryParam)("queryMode",r.StringParam),[i=Ku.hour,o]=(0,r.useQueryParam)("timeFrame",r.StringParam),l=im.parse(a),c=om.parse(i),u=l===sm.top,m=e=>{t((0,To.TX)({text:e}))},p=n.useCallback((()=>(0,d.jsx)(du.a,{options:rm,value:l,onUpdate:s})),[l,s]);return u?(0,d.jsx)(nm,{tenantName:e,timeFrame:c,renderQueryModeControl:p,handleTimeFrameChange:e=>{o(e[0],"replaceIn")},handleDateRangeChange:e=>{t((0,To.TX)(e))},handleTextSearchUpdate:m}):(0,d.jsx)(Qu,{tenantName:e,renderQueryModeControl:p,handleTextSearchUpdate:m})};var cm=a(46496),dm=a(87747);const um=JSON.parse('{"no-data":"No data","filters.mode.immediate":"Immediate","filters.mode.history":"Historical","description":"Historical data only tracks shards with CPU load over 70%"}'),mm=JSON.parse('{"no-data":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445","filters.mode.immediate":"\u041c\u0433\u043d\u043e\u0432\u0435\u043d\u043d\u044b\u0435","filters.mode.history":"\u0418\u0441\u0442\u043e\u0440\u0438\u0447\u0435\u0441\u043a\u0438\u0435","description":"\u0418\u0441\u0442\u043e\u0440\u0438\u0447\u0435\u0441\u043a\u0438\u0435 \u0434\u0430\u043d\u043d\u044b\u0435 \u0445\u0440\u0430\u043d\u044f\u0442\u0441\u044f \u0442\u043e\u043b\u044c\u043a\u043e \u043e \u0448\u0430\u0440\u0434\u0430\u0445 \u0441 \u0437\u0430\u0433\u0440\u0443\u0437\u043a\u043e\u0439 CPU \u0432\u044b\u0448\u0435 70%"}'),pm=(0,he.g4)("ydb-diagnostics-top-shards",{ru:mm,en:um}),hm={start:{value:"now-1h",type:"relative"},end:{value:"now",type:"relative"}},vm=({value:e,onChange:t})=>{const a=e.mode===dm.h.Immediate?void 0:e.from,s=e.mode===dm.h.Immediate?void 0:e.to;return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)(du.a,{value:e.mode,onUpdate:e=>{if(!((e,t)=>Object.values(e).includes(t))(dm.h,e)){const t=Object.values(dm.h).join(", ");throw new Error(`Unexpected TopShards mode "${e}". Should be one of: ${t}`)}t({mode:e})},children:[(0,d.jsx)(du.a.Option,{value:dm.h.Immediate,children:pm("filters.mode.immediate")}),(0,d.jsx)(du.a.Option,{value:dm.h.History,children:pm("filters.mode.history")})]}),(0,d.jsx)(Ju,{from:a,to:s,onChange:e=>{t({mode:dm.h.History,...e})},defaultValue:hm})]})};var gm=a(49228);const ym=(0,c.cn)("top-shards"),xm={...f.N3,dynamicRender:!1,externalSort:!0,disableSortReset:!0,defaultOrder:-1};function fm(e){return e.to="now",e.from="now-1h",e}const bm=({tenantName:e,path:t})=>{var a,s;const r=(0,ql.x)("ShardsTable"),i=(0,b.YQ)(),[o]=(0,b.Nt)(),l=(0,b.N4)((e=>e.shardsWorkload)),[c,u]=n.useState((()=>{const e={...l};return e.mode||(e.mode=dm.h.Immediate),e.from||e.to||fm(e),e})),{tableSort:m,handleTableSort:p,backendSort:h}=function(){const[e,t]=(0,b.GY)({initialSortColumn:gm.Fk.CPUCores,fixedOrderType:-1,multiple:!0}),a=n.useMemo((()=>(0,b.JN)(e,gm.LK)),[e]);return{tableSort:e,handleTableSort:t,backendSort:a}}(),{currentData:v,isFetching:g,error:y}=cm.Xx.useSendShardQueryQuery({database:e,path:t,sortOrder:h,filters:c},{pollingInterval:o}),x=g&&void 0===v,f=(null===v||void 0===v||null===(a=v.resultSets)||void 0===a||null===(s=a[0])||void 0===s?void 0:s.result)||[],j=e=>{const t={...e};if(!l.from&&!l.to&&!e.from&&!e.to)switch(e.mode){case dm.h.Immediate:t.from=t.to=void 0;break;case dm.h.History:fm(t)}i((0,cm.rF)(e)),u((e=>({...e,...t})))},T=n.useMemo((()=>{let e;return e=c.mode===dm.h.History?["Path","CPUCores","DataSize","TabletId","NodeId","PeakTime","InFlightTxCount","IntervalEnd"]:["Path","CPUCores","DataSize","TabletId","NodeId","InFlightTxCount"],e}),[c.mode]);return(0,d.jsxs)(de.L,{children:[(0,d.jsx)(de.L.Controls,{children:(0,d.jsx)(vm,{value:c,onChange:j})}),c.mode===dm.h.History&&(0,d.jsx)("div",{className:ym("hint"),children:pm("description")}),y?(0,d.jsx)(k.o,{error:(0,Ve.Cb)(y)}):null,(0,d.jsx)(de.L.Table,{loading:x,children:y&&!f?null:(0,d.jsx)(r,{database:e,schemaPath:t,columnsIds:T,data:f,settings:xm,onSort:p,sortOrder:m})})]})};var jm=a(41012),Tm=a(31819),Sm=a(72976);const wm=function({disabled:e,view:t="flat-secondary"}){const a=(0,b.YQ)();return(0,d.jsx)(dn.$,{onClick:()=>{a((0,Sm.Jf)())},view:t,disabled:e,title:"Fullscreen",children:(0,d.jsx)(Re.I,{data:Tm.A})})};var Nm,Em=a(98392);function Cm(){return Cm=Object.assign?Object.assign.bind():function(e){for(var t=1;te.fullscreen)),s=(0,b.YQ)(),r=n.useCallback((()=>{s((0,Sm.sM)())}),[s]);n.useEffect((()=>{const e=e=>{"Escape"===e.key&&r()};return document.addEventListener("keydown",e,!1),()=>{document.removeEventListener("keydown",e,!1)}}),[r]);const[i,o]=n.useState(null);n.useEffect((()=>{const e=document.createElement("div");return null===_m||void 0===_m||_m.appendChild(e),e.style.display="contents",o(e),()=>{o(null),e.remove()}}),[]);const l=n.useRef(null);return n.useLayoutEffect((()=>{var e;i&&(a?null===_m||void 0===_m||_m.appendChild(i):null===(e=l.current)||void 0===e||e.appendChild(i))}),[i,a]),i?(0,d.jsx)("div",{ref:l,style:{display:"contents"},children:(0,d.jsx)(Em.Z,{container:i,children:(0,d.jsxs)("div",{className:Dm({fullscreen:a},t),children:[(0,d.jsx)(dn.$,{onClick:r,view:"raised",className:Dm("close-button"),children:(0,d.jsx)(Re.I,{data:Pm})}),(0,d.jsx)("div",{className:Dm("content"),children:e})]})})}):null};var Rm=a(40427),km=a(42265),Om=a(81101),Mm=a(10731),Lm=a(97218),qm=a(80563),zm=a(98934),Fm=a(10662),Um=a(65809);const Qm=JSON.parse('{"label_offset":"Offset","label_partition":"Partition ID","label_timestamp-create":"Timestamp Create","label_timestamp-write":"Timestamp Write","label_ts_diff":"Write Lag","label_key":"Key","label_metadata":"Metadata","label_message":"Message","label_size":"Size","label_original-size":"Original Size","label_codec":"Codec","label_producerid":"ProducerID","label_seqno":"SeqNo","label_partition-id":"Partition ID: ","context_ts-diff":"Timestamp Write - Timestamp Create, ms","label_full-value":"Full value","label_from":"From: ","label_nothing-found":"Nothing found","description_nothing-found":"Make the filter less strict or start over","action_show-all":"Reset filter","label_by-offset":"By offset","label_by-timestamp":"By timestamp","action_scroll-down":"Scroll to the end","action_scroll-selected":"Scroll to selected offset","action_scroll-up":"Scroll to the start","description_failed-decode":"Failed to decode message","description_truncated":"[truncated]","context_message-not-found":"Message with offset {{offset}} not found","context_get-data-error":"Failed to get message","label_download":"Save message to file","label_truncated":"Truncated {{size}}","description_not-loaded-message":"Message was not fetched in table due to problems with big messages.\\nYou can view it in side panel by clicking on Offset","description_removed-message":"Message was deleted due to retention","description_last-messages":"Only last 50 000 messages from any partition are displayed"}'),$m=(0,he.g4)("ydb-diagnostics-topic-data",{en:Qm}),Bm="partition",Hm="offset",Wm="timestampCreate",Gm="timestampWrite",Vm="tsDiff",Jm="metadata",Km="message",Ym="size",Zm="originalSize",Xm="codec",ep="producerID",tp="seqNo",ap={get TIMESTAMP(){return $m("label_by-timestamp")},get OFFSET(){return $m("label_by-offset")}},np=(0,r.createEnumParam)(["TIMESTAMP","OFFSET"]),sp=(0,r.withDefault)(np,"TIMESTAMP");function rp(){const[{selectedPartition:e,selectedOffset:t,startTimestamp:a,topicDataFilter:s,activeOffset:i},o]=(0,r.useQueryParams)({selectedPartition:r.StringParam,selectedOffset:r.StringParam,startTimestamp:r.NumberParam,topicDataFilter:sp,activeOffset:r.StringParam}),l=n.useCallback((e=>{o({selectedPartition:e},"replaceIn")}),[o]),c=n.useCallback((e=>{o({selectedOffset:e},"replaceIn")}),[o]),d=n.useCallback((e=>{o({activeOffset:e},"replaceIn")}),[o]);return{selectedPartition:e,selectedOffset:t,startTimestamp:a,topicDataFilter:s,activeOffset:i,handleSelectedPartitionChange:l,handleSelectedOffsetChange:c,handleStartTimestampChange:n.useCallback((e=>{o({startTimestamp:e},"replaceIn")}),[o]),handleTopicDataFilterChange:n.useCallback((e=>{o({topicDataFilter:e},"replaceIn")}),[o]),handleActiveOffsetChange:d}}const ip=(0,c.cn)("ydb-diagnostics-topic-data"),op={get offset(){return $m("label_offset")},get partition(){return $m("label_partition")},get timestampCreate(){return $m("label_timestamp-create")},get timestampWrite(){return $m("label_timestamp-write")},get tsDiff(){return $m("label_ts_diff")},get key(){return $m("label_key")},get metadata(){return $m("label_metadata")},get message(){return $m("label_message")},get size(){return $m("label_size")},get originalSize(){return $m("label_original-size")},get codec(){return $m("label_codec")},get producerID(){return $m("label_producerid")},get seqNo(){return $m("label_seqno")}},lp={0:"RAW",1:"GZIP",2:"LZOP",3:"ZSTD"};function cp({columnsToSelect:e,handleSelectedColumnsUpdate:t,startOffset:a,endOffset:s,partitions:r,partitionsLoading:i,partitionsError:o,scrollToOffset:l,truncatedData:c}){const{selectedPartition:u,handleSelectedPartitionChange:m,handleSelectedOffsetChange:p,handleStartTimestampChange:h}=rp(),v=null===r||void 0===r?void 0:r.map((({partitionId:e})=>({content:String(e),value:String(e)}))),g=n.useCallback((e=>{m(e[0]),p(void 0),h(void 0)}),[m,h,p]);return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(A.l,{className:ip("partition-select"),label:$m("label_partition-id"),options:v,value:u?[u]:void 0,onUpdate:g,filterable:r&&r.length>5,disabled:!r||!r.length,errorPlacement:"inside",errorMessage:(0,Um.$)(o),error:Boolean(o),loading:i}),(0,d.jsx)(dp,{scrollToOffset:l}),!(0,uu.isNil)(a)&&!(0,uu.isNil)(s)&&(0,d.jsxs)(_e.s,{gap:1,children:[(0,d.jsxs)(De.E,{color:"secondary",whiteSpace:"nowrap",children:[(0,q.ZV)(a),"\u2014",(0,q.ZV)(s-1)]}),c&&(0,d.jsx)(zm.H,{children:$m("description_last-messages")})]}),(0,d.jsx)(Rd.O,{popupWidth:242,items:e,showStatus:!0,onUpdate:t,sortable:!1})]})}function dp({scrollToOffset:e}){const{selectedOffset:t,startTimestamp:a,topicDataFilter:s,activeOffset:r,handleSelectedOffsetChange:i,handleStartTimestampChange:o,handleTopicDataFilterChange:l}=rp(),c=n.useRef(null),u=!(0,uu.isNil)(r);n.useEffect((()=>{var e;u&&(null===(e=c.current)||void 0===e||e.blur())}),[u]);const m=n.useCallback((e=>{"TIMESTAMP"===e?i(void 0):o(void 0),l(e)}),[l,i,o]),p=n.useCallback((e=>{i(e)}),[i]),h=n.useCallback((e=>{let t;if(e){const{value:a,type:n}=e;if("absolute"===n)t=a.valueOf();else if("relative"===n){const e=(0,Ce.bQ)(a);t=e?e.valueOf():void 0}}o(t)}),[o]),v=(0,Ce.bQ)(Number(a));return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)(du.a,{value:s,onUpdate:m,children:[(0,d.jsx)(du.a.Option,{value:"TIMESTAMP",children:ap.TIMESTAMP}),(0,d.jsx)(du.a.Option,{value:"OFFSET",children:ap.OFFSET})]}),"OFFSET"===s&&(0,d.jsx)(Fm.i,{controlRef:c,className:ip("offset-input"),value:t?String(t):"",onUpdate:p,label:$m("label_from"),placeholder:$m("label_offset"),type:"number",debounce:600,endContent:(0,d.jsx)(Ae.m,{title:$m("action_scroll-selected"),children:(0,d.jsx)(dn.$,{disabled:(0,uu.isNil)(t)||""===t,className:ip("scroll-button"),view:"flat-action",size:"xs",onClick:()=>{t&&e((0,Er.y3)(t))},children:(0,d.jsx)(Re.I,{size:14,data:qm.A})})}),autoFocus:!0}),"TIMESTAMP"===s&&(0,d.jsx)(Lm.x,{format:"YYYY-MM-DD HH:mm:ss",placeholder:"YYYY-MM-DD HH:mm:ss",hasClear:!0,isDateUnavailable:e=>e.isAfter((0,Ce.bQ)()),label:$m("label_from"),onUpdate:h,defaultValue:v?{type:"absolute",value:v}:null,className:ip("date-picker")})]})}var up=a(92159),mp=a(74529);function pp(e,t){const a=document.createElement("a");a.href=e,a.download=t,document.body.appendChild(a),a.click(),document.body.removeChild(a)}const hp=(e,t,a)=>{const n=new Blob([e],{type:a}),s=URL.createObjectURL(n);pp(s,t),URL.revokeObjectURL(s)},vp=(0,c.cn)("ydb-diagnostics-message-details"),gp=1e7;function yp({children:e,title:t,className:a,renderToolbar:n}){return(0,d.jsxs)(_e.s,{direction:"column",className:vp("section",a),children:[(0,d.jsxs)(_e.s,{className:vp("section-title-wrapper"),justifyContent:"space-between",alignItems:"center",children:[t,null===n||void 0===n?void 0:n()]}),(0,d.jsx)("div",{className:vp("section-content"),children:(0,d.jsx)("div",{className:vp("section-scroll-container"),children:e})})]})}function xp({offset:e,size:t,message:a}){const s=(0,b.N4)((e=>e.fullscreen)),{preparedMessage:r,decodedMessage:i,convertedMessage:o}=n.useMemo((()=>{let e,n=a,s=a;try{s=atob(a)}catch(r){console.warn(r)}try{const e=JSON.parse(s);n=e&&"object"===typeof e?e:s}catch(r){console.warn(r)}return"object"===typeof n&&(0,Er.y3)(t)<=1e6?e=Tn(n):n&&"object"===typeof n&&(n=JSON.stringify(n,null,2)),{preparedMessage:n,decodedMessage:s,convertedMessage:e}}),[a,t]),l=Boolean(o)?(0,d.jsx)(os,{collapsedInitially:!0,value:o,maxValueWidth:50,toolbarClassName:vp("json-viewer-toolbar")},String(s)):(0,d.jsx)("div",{className:vp("string-message"),children:(0,d.jsx)(mp.A,{value:r,limit:2e3},String(s))}),c=(0,Er.y3)(t)>gp;return(0,d.jsx)(yp,{title:(0,d.jsx)(fp,{truncated:c}),renderToolbar:()=>(0,d.jsxs)(_e.s,{gap:1,children:[(0,d.jsx)(Ae.m,{title:$m("label_download"),children:(0,d.jsx)(dn.$,{view:"flat-secondary",onClick:t=>{t.stopPropagation(),hp(i,`topic-message-${null!==e&&void 0!==e?e:"unknown-offset"}`)},children:(0,d.jsx)(Re.I,{data:up.A})})}),(0,d.jsx)(cn.b,{view:"flat-secondary",text:i})]}),className:vp("message"),children:l})}function fp({truncated:e}){return(0,d.jsxs)("span",{children:[$m("label_message"),e&&(0,d.jsxs)(n.Fragment,{children:[" ",(0,d.jsxs)(De.E,{color:"secondary",children:["[",$m("label_truncated",{size:(0,Er.IG)(gp)}),"]"]})]})]})}var bp=a(23900),jp=a(94420);const Tp=(0,c.cn)("ydb-diagnostics-topic-data-columns"),Sp={name:Hm,header:op[Hm],align:Pt.Ay.LEFT,render:({row:e})=>{const{Offset:t,removed:a,notLoaded:n}=e;return(0,d.jsx)(Lp,{offset:t,removed:a,notLoaded:n})},width:100},wp={name:Wm,header:(0,d.jsx)(Yd,{title:op[Wm]}),align:Pt.Ay.LEFT,render:({row:{CreateTimestamp:e}})=>e?(0,d.jsx)(_s.c,{showStatus:!1,renderName:()=>(0,d.jsx)(Mp,{timestamp:e}),name:(0,q.Ey)(e),hasClipboardButton:!0}):f.Pd,width:220},Np={name:Gm,header:(0,d.jsx)(Yd,{title:op[Gm]}),align:Pt.Ay.LEFT,render:({row:{WriteTimestamp:e}})=>e?(0,d.jsx)(_s.c,{showStatus:!1,renderName:()=>(0,d.jsx)(Mp,{timestamp:e}),name:(0,q.Ey)(e),hasClipboardButton:!0}):f.Pd,width:220},Ep={name:Vm,header:op[Vm],align:Pt.Ay.RIGHT,render:({row:{TimestampDiff:e}})=>(0,d.jsx)(qp,{value:e}),width:110,note:$m("context_ts-diff")},Cp={name:Jm,header:op[Jm],align:Pt.Ay.LEFT,render:({row:{MessageMetadata:e}})=>{if(!e)return f.Pd;const t=e.map((({Key:e="",Value:t=""})=>`${e}: ${t}`));return t.join(", ")},width:200},Pp={name:Km,header:op[Km],align:Pt.Ay.LEFT,render:({row:{Message:e,OriginalSize:t}})=>(0,d.jsx)(zp,{message:e,size:t}),width:500},Ip={name:Ym,header:op[Ym],align:Pt.Ay.RIGHT,render:({row:{StorageSize:e}})=>(0,d.jsx)(Fp,{size:e}),width:100},Dp={name:Zm,header:(0,d.jsx)(Yd,{title:op[Zm]}),align:Pt.Ay.RIGHT,render:({row:e})=>(0,q.z3)(e.OriginalSize),width:100},_p={name:Xm,header:op[Xm],align:Pt.Ay.RIGHT,render:({row:{Codec:e}})=>{var t;return(0,uu.isNil)(e)?f.Pd:null!==(t=lp[e])&&void 0!==t?t:e},width:70},Ap={name:ep,header:op[ep],align:Pt.Ay.LEFT,render:({row:e})=>e.ProducerId?(0,d.jsx)(_s.c,{showStatus:!1,name:e.ProducerId,hasClipboardButton:!0}):f.Pd,width:100},Rp={name:tp,header:op[tp],align:Pt.Ay.RIGHT,render:({row:e})=>e.SeqNo?(0,d.jsx)(_s.c,{showStatus:!1,name:e.SeqNo,hasClipboardButton:!0}):f.Pd,width:100};const kp=["offset","timestampCreate","tsDiff","message"],Op=["offset"];function Mp({timestamp:e}){if(!e)return f.Pd;const t=(0,q.Ey)(e).split("."),a=t.pop();return(0,d.jsxs)(De.E,{variant:"body-2",children:[t.join("."),(0,d.jsxs)(De.E,{color:"secondary",variant:"body-2",children:[".",a]})]})}function Lp({offset:e,removed:t,notLoaded:a}){const n=Lc(),{handleActiveOffsetChange:s}=rp();if((0,uu.isNil)(e))return f.Pd;if(t)return(0,d.jsx)(Ae.m,{title:$m("description_removed-message"),placement:"right",children:(0,d.jsx)(De.E,{className:Tp("offset",{removed:!0}),variant:"body-2",children:e})});const r=n(S.iJ.topicData,{activeOffset:String(e)});return(0,d.jsxs)(N.N_,{to:r,onClick:t=>{t.stopPropagation(),t.preventDefault();const a=String(e);s(a)},className:Tp("offset",{link:!0}),children:[(0,d.jsx)(De.E,{variant:"body-2",color:"info",children:e}),a&&(0,d.jsx)(ea.A,{content:(0,d.jsx)(De.E,{className:Tp("help"),children:$m("description_not-loaded-message")}),className:Tp("help-popover"),children:(0,d.jsx)(De.E,{color:"secondary",className:Tp("help-popover"),children:(0,d.jsx)(Re.I,{data:jp.A})})})]})}function qp({value:e,baseColor:t="primary",variant:a="body-2"}){if((0,uu.isNil)(e))return f.Pd;const n=(0,Er.y3)(e);return(0,d.jsx)(De.E,{variant:a,color:n>=1e5?"danger":t,children:(0,ze.Xo)(n)})}function zp({message:e,size:t}){if((0,uu.isNil)(e))return f.Pd;let a,n=!1;try{a=atob(e)}catch{a=$m("description_failed-decode"),n=!0}const s=(0,Er.y3)(t)>100;return(0,d.jsxs)(De.E,{variant:"body-2",color:n?"secondary":"primary",className:Tp("message",{invalid:n}),children:[a,s&&(0,d.jsxs)(De.E,{color:"secondary",className:Tp("truncated"),children:[" ",$m("description_truncated")]})]})}function Fp({size:e}){return(0,q.z3)(e)}function Up(e,t=f.Pd){return(0,uu.isNil)(e)?t:e}const Qp={name:Bm,header:op[Bm],render:()=>(0,d.jsx)(Vp,{})},$p={name:Hm,header:op[Hm],render:({row:e})=>Up(e.Offset)},Bp={name:Wm,header:op[Wm],render:({row:e})=>(0,d.jsx)(Mp,{timestamp:e.CreateTimestamp})},Hp={name:Gm,header:op[Gm],render:({row:e})=>(0,d.jsx)(Mp,{timestamp:e.WriteTimestamp})},Wp={name:ep,header:op[ep],render:({row:e})=>Up(e.ProducerId)},Gp={name:tp,header:op[tp],render:({row:e})=>Up(e.SeqNo)};function Vp(){const{selectedPartition:e}=rp();return e}const Jp=[Qp,$p,Bp,Hp,Ep,Cp,Pp,Ip,Dp,_p,Wp,Gp],Kp=[[{name:Bm},{name:Hm},{name:Ym}],[{name:Wm,copy:e=>(0,q.Ey)(e.CreateTimestamp)},{name:Gm,copy:e=>(0,q.Ey)(e.WriteTimestamp)},{name:Vm}],[{name:Zm},{name:Xm},{name:ep,copy:e=>e.ProducerId},{name:tp,copy:e=>e.SeqNo}]];function Yp({messageData:e}){return(0,d.jsx)(_e.s,{direction:"column",gap:3,className:vp("details"),children:Kp.map(((t,a)=>(0,d.jsx)(bp.u,{className:vp("list"),nameMaxWidth:200,children:t.map((t=>{var a,n;const s=Jp.find((e=>e.name===t.name)),r=null===(a=t.copy)||void 0===a?void 0:a.call(t,e);return(0,d.jsx)(bp.u.Item,{name:null===s||void 0===s?void 0:s.header,copyText:r,children:null===s||void 0===s||null===(n=s.render)||void 0===n?void 0:n.call(s,{row:e})},t.name)}))},a)))})}function Zp({data:e}){return(0,d.jsx)(yp,{title:$m("label_metadata"),children:(0,d.jsx)(bp.u,{nameMaxWidth:200,className:vp("message-meta"),children:e.map((e=>(0,d.jsx)(bp.u.Item,{name:e.Key,copyText:e.Value,children:e.Value},e.Key)))})})}function Xp({database:e,path:t}){var a;const{selectedPartition:s,activeOffset:r}=rp(),i=n.useMemo((()=>{if((0,uu.isNil)(s)||(0,uu.isNil)(r))return Dd.hT;const a={database:e,path:t,partition:s,limit:1,message_size_limit:gp},n=(0,Er.y3)(r);return a.offset=n,a.last_offset=n+1,a}),[s,r,e,t]),{currentData:l,error:c,isFetching:u}=ua.useGetTopicDataQuery(i),m=null===l||void 0===l||null===(a=l.Messages)||void 0===a?void 0:a[0],p=()=>{const e=null===m||void 0===m?void 0:m.MessageMetadata;return e?(0,d.jsx)(Zp,{data:e}):null},h=()=>{const e=null===m||void 0===m?void 0:m.Message;return e?(0,d.jsx)(xp,{message:e,offset:m.Offset,size:m.OriginalSize}):null};return(0,d.jsx)(o.r,{loading:u,children:(0,d.jsx)("div",{className:vp(),children:(()=>{var e;const t=(0,j.cH)(c),a=t&&404===c.status,n=l&&!(null!==(e=l.Messages)&&void 0!==e&&e.length);if(Boolean(n||a))return(0,d.jsxs)(_e.s,{direction:"column",grow:"grow",alignItems:"center",justifyContent:"center",height:"100%",children:[(0,d.jsx)(De.E,{variant:"subheader-2",children:$m("context_message-not-found",{offset:r})}),(0,d.jsx)(Re.I,{data:Du,size:100})]});if(c){let e=$m("context_get-data-error");return t&&"string"===typeof c.data?e=c.data:t&&c.statusText&&(e=c.statusText),(0,d.jsx)(De.E,{color:"danger",variant:"body-2",children:e})}return(0,d.jsxs)(_e.s,{direction:"column",gap:4,children:[m?(0,d.jsx)(Yp,{messageData:m}):null,p(),h()]})})()})})}const eh={data:[],total:0,found:0};const th=({setBoundOffsets:e,baseOffset:t=0})=>async({limit:a,offset:n,filters:s})=>{if(!s)return eh;const{partition:r,isEmpty:i,...o}=s;if((0,uu.isNil)(r)||""===r||i)return eh;const l=t+n,c={...o,partition:r,limit:a,last_offset:l+a,message_size_limit:100};c.offset=l;const d=await window.api.viewer.getTopicData(c),{start:u,end:m,messages:p}=function(e,t){const{StartOffset:a,EndOffset:n,Messages:s=[]}=e,r=(0,Er.y3)(a),i=(0,Er.y3)(n),o=[],l=Math.min(20,Math.max(i-t,0));let c=0,d=0;for(;d()=>{P(void 0),E(void 0),C(void 0)}),[P,E,C]);const D=n.useMemo((()=>{if((0,uu.isNil)(j))return Dd.hT;const e={database:a,path:t,partition:j,limit:1};return S?e.read_timestamp=S:e.offset=(0,Er.y3)(T),e}),[j,T,S,a,t]),{currentData:_,error:A,isFetching:R}=ua.useGetTopicDataQuery(D),{data:k,isLoading:O,error:M}=Ad.aD.useGetPartitionsQuery({path:t,database:a},{pollingInterval:s}),L=n.useRef(j);n.useEffect((()=>{const e=j!==L.current,t=null===k||void 0===k?void 0:k.find((({partitionId:e})=>e===j));if(t){let n=x;if(x&&!e||(n=(0,Er.y3)(t.endOffset),f(n)),!h||e){var a;const e=(0,Er.y3)(t.startOffset),s=Math.max((null!==(a=n)&&void 0!==a?a:0)-5e4,e);y(s!==e),v(s)}}e&&(L.current=j)}),[j,k,x,h]),n.useEffect((()=>{if(k&&k.length&&(0,uu.isNil)(j)){const e=k[0].partitionId;P((0,uu.isNil)(e)?void 0:String(e))}}),[k,j,P]);const{columnsToShow:q,columnsToSelect:z,setColumns:F}=(0,Su.K)(ah,"topicDataSelectedColumns",op,kp,Op),U=n.useCallback((({startOffset:e,endOffset:t})=>{i(e),l(t)}),[]);n.useEffect((()=>{var e,t;R||!_&&!A||(null!==_&&void 0!==_&&null!==(e=_.Messages)&&void 0!==e&&e.length||!_&&!A?p(!1):_&&null!==(t=_.Messages)&&void 0!==t&&t.length&&!A||p(!0),_&&U({startOffset:(0,Er.y3)(_.StartOffset),endOffset:(0,Er.y3)(_.EndOffset)}))}),[R,_,A,U]);const Q=n.useMemo((()=>({path:t,database:a,partition:null!==j&&void 0!==j?j:"",isEmpty:m})),[t,a,j,m]),$=n.useCallback((()=>{E(void 0),C(void 0),"TIMESTAMP"===w&&u((e=>e+1))}),[E,C,w]),B=n.useCallback((t=>{var a;const n=(t-(null!==h&&void 0!==h?h:0))*Rm.U3,s=Math.max(0,n);null===(a=e.current)||void 0===a||a.scrollTo({top:s,behavior:"instant"})}),[h,e]),H=n.useRef(N);n.useEffect((()=>{if(R)return;let e;if((0,uu.isNil)(H.current)){const t=null===_||void 0===_?void 0:_.Messages;null!==t&&void 0!==t&&t.length&&(e=(0,Er.y3)(t[0].Offset))}else e=(0,Er.y3)(H.current),H.current=void 0;(0,uu.isNil)(e)||B(e)}),[_,R,B]);const W=n.useCallback((()=>(0,d.jsx)(cp,{columnsToSelect:z,handleSelectedColumnsUpdate:F,partitions:k,partitionsLoading:O,partitionsError:M,startOffset:r,endOffset:o,truncatedData:g,scrollToOffset:B},c)),[z,c,o,k,M,O,B,F,r,g]),G=n.useMemo((()=>th({setBoundOffsets:U,baseOffset:h})),[h,U]),V=n.useCallback((()=>{I(void 0)}),[I]),J=n.useCallback((()=>(0,d.jsx)(Am,{children:(0,d.jsx)(Xp,{database:a,path:t})})),[a,t]);return!(0,uu.isNil)(h)&&!(0,uu.isNil)(x)&&(0,d.jsx)(Tu,{isDrawerVisible:!(0,uu.isNil)(N),onCloseDrawer:V,renderDrawerContent:J,drawerId:"topic-data-details",storageKey:"topic-data-details-drawer-width",detectClickOutside:!0,isPercentageWidth:!0,drawerControls:[{type:"copyLink",link:window.location.href},{type:"custom",node:(0,d.jsx)(wm,{disabled:Boolean(A),view:"flat"}),key:"fullscreen"},{type:"close"}],title:$m("label_message"),headerClassName:ip("drawer-header"),children:(0,d.jsx)(km.o,{controls:W(),table:(0,d.jsx)(Rm.k5,{columnsWidthLSKey:"topicDataColumnsWidth",scrollContainerRef:e,columns:q,fetchData:G,initialEntitiesCount:x-h,limit:20,renderErrorMessage:Om.$,renderEmptyDataMessage:()=>{const e=T||S;return(0,d.jsx)(Mm.U,{title:$m("label_nothing-found"),message:$m("description_nothing-found"),onShowAll:e?$:void 0,showAll:$m("action_show-all"),image:(0,d.jsx)(jm.oN,{width:230,height:230})})},filters:Q,tableName:"topicData",rowHeight:Rm.U3,keepCache:!1,getRowClassName:e=>ip("row",{active:Boolean(String(e.Offset)===T||String(e.Offset)===N),removed:e.removed})}),tableProps:{scrollContainerRef:e,scrollDependencies:[h,x,Q]},fullHeight:!0})})}const sh=(0,c.cn)("kv-tenant-diagnostics");const rh=function(e){const t=n.useRef(null),a=(0,b.YQ)(),{diagnosticsTab:r=S.iJ.overview}=(0,b.N4)((e=>e.tenant)),i=Lc(),o=vt(e.type)?e.path:e.tenantName,l=(0,D._Q)(),c=(0,D._p)(),u=Mc(e.type,e.subType,{hasFeatureFlags:l,hasTopicData:c,isTopLevel:e.path===e.tenantName});let m=u.find((e=>e.id===r));return m||(m=u[0]),n.useEffect((()=>{m&&m.id!==r&&a((0,_.WO)(m.id))}),[m,r,a]),(0,d.jsxs)("div",{className:sh(),children:[m?(0,d.jsx)(s.mg,{children:(0,d.jsx)("title",{children:m.title})}):null,(()=>{var e;return(0,d.jsx)("div",{className:sh("header-wrapper"),children:(0,d.jsxs)("div",{className:sh("tabs"),children:[(0,d.jsx)(w.t,{size:"l",items:u,activeTab:null===(e=m)||void 0===e?void 0:e.id,wrapTo:({id:e},t)=>{const a=i(e);return(0,d.jsx)(N.N_,{to:a,className:sh("tab"),children:t},e)},allowNotSelected:!0}),(0,d.jsx)(E.E,{onManualRefresh:()=>{const e=new CustomEvent("diagnosticsRefresh");document.dispatchEvent(e)}})]})})})(),(0,d.jsx)(I,{children:(0,d.jsx)("div",{className:sh("page-wrapper"),ref:t,children:(()=>{var a;const{type:n,path:s}=e;switch(null===(a=m)||void 0===a?void 0:a.id){case S.iJ.overview:return(0,d.jsx)(oc,{type:n,tenantName:o,path:s,additionalTenantProps:e.additionalTenantProps,additionalNodesProps:e.additionalNodesProps});case S.iJ.schema:return(0,d.jsx)(Zt,{path:s,tenantName:o,type:n,extended:!0});case S.iJ.topQueries:return(0,d.jsx)(lm,{tenantName:o});case S.iJ.topShards:return(0,d.jsx)(bm,{tenantName:o,path:s});case S.iJ.nodes:return(0,d.jsx)(oe.G,{path:s,database:o,additionalNodesProps:e.additionalNodesProps,scrollContainerRef:t});case S.iJ.tablets:return(0,d.jsx)(We.C,{scrollContainerRef:t,path:s,database:o});case S.iJ.storage:return(0,d.jsx)(He.z,{database:o,scrollContainerRef:t});case S.iJ.network:return(0,d.jsx)(Id,{path:s,database:o,additionalNodesProps:e.additionalNodesProps,scrollContainerRef:t});case S.iJ.describe:return(0,d.jsx)(ds,{path:s,database:o});case S.iJ.hotKeys:return(0,d.jsx)(Vc,{path:s,database:o});case S.iJ.graph:return(0,d.jsx)(ie,{path:s,database:o});case S.iJ.consumers:return(0,d.jsx)(ln,{path:s,database:o,type:n});case S.iJ.partitions:return(0,d.jsx)(cu,{path:s,database:o});case S.iJ.topicData:return(0,d.jsx)(nh,{path:s,database:o,scrollContainerRef:t},s);case S.iJ.configs:return(0,d.jsx)(ia,{database:o});case S.iJ.operations:return(0,d.jsx)(Be,{database:o});default:return(0,d.jsx)("div",{children:"No data..."})}})()})})]})},ih=JSON.parse('{"controls.query-mode-selector_type":"Query type:","tabs.newQuery":"Editor","tabs.history":"History","tabs.saved":"Saved","history.empty":"History is empty","history.empty-search":"Search result is empty","saved.empty":"There are no saved queries","delete-dialog.header":"Delete query","delete-dialog.question":"Are you sure you want to delete query","delete-dialog.delete":"Delete","delete-dialog.cancel":"Cancel","preview.title":"Preview","preview.not-available":"Preview is not available","preview.close":"Close preview","preview.truncated":"truncated","method-description.script":"For YQL-scripts combining DDL and DML.\\nAPI call: schema.scripting","method-description.scan":"Read-only queries, potentially reading a lot of data.\\nAPI call: table.ExecuteScan","method-description.data":"DML queries for changing and fetching data in serialization mode.\\nAPI call: table.executeDataQuery","method-description.query":"Any query. An experimental API call supposed to replace all existing methods.\\nAPI Call: query.ExecuteScript","method-description.pg":"Queries in postgresql syntax.\\nAPI call: query.ExecuteScript","transaction-mode-description.serializable":"Provides the strictest isolation level for custom transactions","transaction-mode-description.onlinero":"Each read operation in the transaction is reading the data that is most recent at execution time","transaction-mode-description.stalero":"Read operations within a transaction may return results that are slightly out-of-date (lagging by fractions of a second)","transaction-mode-description.snapshot":"All the read operations within a transaction access the database snapshot. All the data reads are consistent","transaction-mode-description.implicit":"No transaction","tracing-level-description.basic":"Spans of main component operations","tracing-level-description.detailed":"Highest detail applicable for diagnosing problems in production","tracing-level-description.diagnostic":"Detailed debugging information for developers","tracing-level-description.off":"No tracing","tracing-level-description.toplevel":"Lowest detail, no more than two spans per request to the component","tracing-level-description.trace":"Very detailed debugging information","statistics-mode-description.none":"Don\'t collect statistics","statistics-mode-description.basic":"Collect statistics","statistics-mode-description.full":"Collect statistics and query plan","statistics-mode-description.profile":"Collect statistics for individual tasks","action.send-query":"Send query","action.send-selected-query":"Send selected query","action.previous-query":"Previous query in history","action.next-query":"Next query in history","action.save-query":"Save query","action.stop":"Stop","action.run":"Run","action.explain":"Explain","action.open-shortcuts":"Open Keyboard Shortcuts Panel","filter.text.placeholder":"Search by query text...","gear.tooltip":"Query execution settings have been changed for ","banner.query-settings.message":"Query was executed with modified settings: ","banner.query-stopped.message":"Data is not up to date because the request was not completed.","banner.query-stopped.never-show":"Never show again","toaster.stop-error":"Something went wrong. Unable to stop request processing. Please wait.","history.queryText":"Query text","history.endTime":"End time","history.duration":"Duration"}'),oh=(0,he.g4)("ydb-query-editor",{en:ih}),lh=(0,c.cn)("ydb-queries-history");const ch=function({changeUserInput:e}){const t=(0,b.YQ)(),a=(0,b.N4)(So.py),n=(0,b.N4)(So.jY),s=[...a].reverse(),r=Go((a=>{e({input:a.queryText}),t((0,So.Xb)(!1)),t((0,_.sH)(S.tQ.newQuery))})),i=[{name:"queryText",header:oh("history.queryText"),render:({row:e})=>(0,d.jsx)("div",{className:lh("query"),children:(0,d.jsx)(Jo,{value:e.queryText,maxQueryHeight:6})}),sortable:!1,width:600},{name:"EndTime",header:oh("history.endTime"),render:({row:e})=>e.endTime?(0,q.r6)(e.endTime.toString()):"-",align:"right",width:200,sortable:!1},{name:"Duration",header:oh("history.duration"),render:({row:e})=>e.durationUs?(0,ze.Xo)((0,ze.Jc)(e.durationUs)):"-",align:"right",width:150,sortable:!1}];return(0,d.jsxs)(de.L,{className:lh(),children:[(0,d.jsx)(de.L.Controls,{children:(0,d.jsx)(pe.v,{value:n,onChange:e=>{t((0,So.Ni)(e))},placeholder:oh("filter.text.placeholder"),className:lh("search")})}),(0,d.jsx)(de.L.Table,{children:(0,d.jsx)(ce.l,{columnsWidthLSKey:"queriesHistoryTableColumnsWidth",columns:i,data:s,settings:Xo,emptyDataMessage:oh(n?"history.empty-search":"history.empty"),onRowClick:e=>r(e),rowClassName:()=>lh("table-row")})})]})};var dh=a(72093);function uh(e,t){const a=new Map(Object.entries(e)),n=new Map(Object.entries(t));return Array.from(a.keys()).filter((e=>a.has(e)&&void 0!==a.get(e)&&a.get(e)!==n.get(e)))}const mh=JSON.parse('{"action.settings":"Query settings","form.query-mode":"Query type","form.timeout":"Timeout","form.transaction-mode":"Transaction mode","form.statistics-mode":"Statistics collection mode","form.tracing-level":"Tracing level","form.limit-rows":"Limit rows","button-done":"Save","tooltip_plan-to-svg-statistics":"Statistics option is set to \\"Full\\" due to the enabled \\"Execution plan\\" experiment.\\n To disable it, go to the \\"Experiments\\" section in the user settings.","button-cancel":"Cancel","form.timeout.seconds":"sec","form.limit.rows":"rows","form.timeout.disabled":"Not available to turn off in this query type","form.validation.timeout":"Must be positive","form.validation.limitRows":"Must be between 1 and 100000","description.default":" (default)","docs":"Documentation"}'),ph=JSON.parse('{"action.settings":"\u041d\u0430\u0441\u0442\u0440\u043e\u0439\u043a\u0438 \u0437\u0430\u043f\u0440\u043e\u0441\u0430","form.query-mode":"\u0422\u0438\u043f \u0437\u0430\u043f\u0440\u043e\u0441\u0430","form.timeout":"\u0422\u0430\u0439\u043c\u0430\u0443\u0442","form.transaction-mode":"\u0423\u0440\u043e\u0432\u0435\u043d\u044c \u0438\u0437\u043e\u043b\u044f\u0446\u0438\u0438","form.statistics-mode":"\u0420\u0435\u0436\u0438\u043c \u0441\u0431\u043e\u0440\u0430 \u0441\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0438","form.tracing-level":"Tracing level","form.limit-rows":"\u041b\u0438\u043c\u0438\u0442 \u0441\u0442\u0440\u043e\u043a","tooltip_plan-to-svg-statistics":"\u041e\u043f\u0446\u0438\u044f \u0441\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0438 \u0443\u0441\u0442\u0430\u043d\u043e\u0432\u043b\u0435\u043d\u0430 \u0432 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \\"Full\\" \u0438\u0437-\u0437\u0430 \u0432\u043a\u043b\u044e\u0447\u0435\u043d\u043d\u043e\u0433\u043e \u044d\u043a\u0441\u043f\u0435\u0440\u0438\u043c\u0435\u043d\u0442\u0430 \\"Execution plan\\".\\n \u0427\u0442\u043e\u0431\u044b \u043e\u0442\u043a\u043b\u044e\u0447\u0438\u0442\u044c \u0435\u0433\u043e, \u043f\u0435\u0440\u0435\u0439\u0434\u0438\u0442\u0435 \u0432 \u0440\u0430\u0437\u0434\u0435\u043b \\"Experiments\\" \u0432 \u043d\u0430\u0441\u0442\u0440\u043e\u0439\u043a\u0430\u0445 \u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u0435\u043b\u044f.","button-done":"\u0413\u043e\u0442\u043e\u0432\u043e","button-cancel":"\u041e\u0442\u043c\u0435\u043d\u0438\u0442\u044c","form.timeout.seconds":"\u0441\u0435\u043a","form.limit.rows":"\u0441\u0442\u0440\u043e\u043a","form.timeout.disabled":"\u041d\u0435\u0432\u043e\u0437\u043c\u043e\u0436\u043d\u043e \u0432\u044b\u043a\u043b\u044e\u0447\u0438\u0442\u044c \u0434\u043b\u044f \u0442\u0435\u043a\u0443\u0449\u0435\u0433\u043e \u0442\u0438\u043f\u0430 \u0437\u0430\u043f\u0440\u043e\u0441\u0430","form.validation.timeout":"\u0422\u0430\u0439\u043c\u0430\u0443\u0442 \u0434\u043e\u043b\u0436\u0435\u043d \u0431\u044b\u0442\u044c \u043f\u043e\u043b\u043e\u0436\u0438\u0442\u0435\u043b\u044c\u043d\u044b\u043c","form.validation.limitRows":"\u041b\u0438\u043c\u0438\u0442 \u0441\u0442\u0440\u043e\u043a \u0434\u043e\u043b\u0436\u0435\u043d \u0431\u044b\u0442\u044c \u043c\u0435\u0436\u0434\u0443 1 \u0438 100000","description.default":" (default)","docs":"\u0414\u043e\u043a\u0443\u043c\u0435\u043d\u0442\u0430\u0446\u0438\u044f"}'),hh=(0,he.g4)("ydb-query-settings-dialog",{en:mh,ru:ph}),vh=[{value:Ve.Wg.implicit,content:Ve._d[Ve.Wg.implicit],text:oh("transaction-mode-description.implicit"),isDefault:!0},{value:Ve.Wg.serializable,content:Ve._d[Ve.Wg.serializable],text:oh("transaction-mode-description.serializable")},{value:Ve.Wg.onlinero,content:Ve._d[Ve.Wg.onlinero],text:oh("transaction-mode-description.onlinero")},{value:Ve.Wg.stalero,content:Ve._d[Ve.Wg.stalero],text:oh("transaction-mode-description.stalero")},{value:Ve.Wg.snapshot,content:Ve._d[Ve.Wg.snapshot],text:oh("transaction-mode-description.snapshot")}],gh=[{value:Ve.ei.query,content:Ve.om[Ve.ei.query],text:oh("method-description.query"),isDefault:!0},{value:Ve.ei.script,content:Ve.om[Ve.ei.script],text:oh("method-description.script")},{value:Ve.ei.scan,content:Ve.om[Ve.ei.scan],text:oh("method-description.scan")},{value:Ve.ei.data,content:Ve.om[Ve.ei.data],text:oh("method-description.data")},{value:Ve.ei.pg,content:Ve.om[Ve.ei.pg],text:oh("method-description.pg")}],yh=[{value:Ve.pE.none,content:Ve.Pn[Ve.pE.none],text:oh("statistics-mode-description.none"),isDefault:!0},{value:Ve.pE.basic,content:Ve.Pn[Ve.pE.basic],text:oh("statistics-mode-description.basic")},{value:Ve.pE.full,content:Ve.Pn[Ve.pE.full],text:oh("statistics-mode-description.full")},{value:Ve.pE.profile,content:Ve.Pn[Ve.pE.profile],text:oh("statistics-mode-description.profile")}],xh=[{value:Ve.PB.off,content:Ve.PX[Ve.PB.off],text:oh("tracing-level-description.off"),isDefault:!0},{value:Ve.PB.toplevel,content:Ve.PX[Ve.PB.toplevel],text:oh("tracing-level-description.toplevel")},{value:Ve.PB.basic,content:Ve.PX[Ve.PB.basic],text:oh("tracing-level-description.basic")},{value:Ve.PB.detailed,content:Ve.PX[Ve.PB.detailed],text:oh("tracing-level-description.detailed")},{value:Ve.PB.diagnostic,content:Ve.PX[Ve.PB.diagnostic],text:oh("tracing-level-description.diagnostic")},{value:Ve.PB.trace,content:Ve.PX[Ve.PB.trace],text:oh("tracing-level-description.trace")}],fh={transactionMode:{title:hh("form.transaction-mode"),options:vh},queryMode:{title:hh("form.query-mode"),options:gh},statisticsMode:{title:hh("form.statistics-mode"),options:yh},tracingLevel:{title:hh("form.tracing-level"),options:xh},timeout:{title:hh("form.timeout")},limitRows:{title:hh("form.limit-rows")}};function bh({currentSettings:e,defaultSettings:t}){const a=uh(e,t),n={};return a.forEach((t=>{const a=fh[t],s=e[t];if("options"in a){var r;const e=null===(r=a.options.find((e=>e.value===s)))||void 0===r?void 0:r.content;e&&(n[a.title]=e)}else s&&(n[a.title]=String(s))})),n}var jh=a(80967);const Th=()=>{const[e,t]=(0,jh.i)(f.fr);let a;try{a=Ve.id.parse(e)}catch{a=void 0}return[a,t]};var Sh=a(95312);const wh=()=>{const[e,t]=(0,jh.i)(f.YQ),[a]=Th(),[n]=(0,Sh.X)(),s=a?uh(a,Ve.jU):[],r=n?uh(n,Ve.jU):[],i=s.includes("transactionMode")||s.includes("queryMode"),o=a?bh({currentSettings:a,defaultSettings:Ve.jU}):{},l=n?bh({currentSettings:n,defaultSettings:Ve.jU}):{},c=e&&Date.now()-e<1e3*f.Du;return{isBannerShown:i&&!c,closeBanner:()=>t(Date.now()),resetBanner:()=>t(void 0),changedCurrentSettings:r,changedCurrentSettingsDescriptions:l,changedLastExecutionSettings:s,changedLastExecutionSettingsDescriptions:o}};var Nh=a(53472);let Eh=function(e){return e.triggerCollapse="triggerCollapse",e.triggerExpand="triggerExpand",e.clear="clear",e}({});const Ch=e=>{localStorage.setItem(e,"true")},Ph=e=>{localStorage.removeItem(e)};function Ih(e){return function(t,a){switch(a){case Eh.triggerCollapse:return Ch(e),{...t,triggerCollapse:!0,triggerExpand:!1,collapsed:!0};case Eh.triggerExpand:return Ph(e),{...t,triggerCollapse:!1,triggerExpand:!0,collapsed:!1};case Eh.clear:return Ph(e),{triggerCollapse:!1,triggerExpand:!1,collapsed:!1};default:return t}}}const Dh=(0,c.cn)("kv-pane-visibility-button");function _h({onCollapse:e,onExpand:t,isCollapsed:a,initialDirection:s="top",className:r}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Ae.m,{title:"Collapse",children:(0,d.jsx)(dn.$,{view:"flat-secondary",onClick:e,className:Dh({hidden:a,type:"collapse"},r),children:(0,d.jsx)(Re.I,{data:Nh.A,className:Dh({[s]:!0})})})}),(0,d.jsx)(Ae.m,{title:"Expand",children:(0,d.jsx)(dn.$,{view:"flat-secondary",onClick:t,className:Dh({hidden:!a,type:"expand"},r),children:(0,d.jsx)(Re.I,{data:Nh.A,className:Dh({[s]:!0},"rotate")})})})]})}const Ah=(0,c.cn)("ydb-preview");function Rh({path:e,quantity:t=0,truncated:a,renderResult:n,loading:s,error:r}){const i=(0,b.YQ)(),l=()=>{i((0,x.o)(!1))};return(0,d.jsx)(o.r,{loading:s,children:(0,d.jsxs)("div",{className:Ah(),children:[(0,d.jsxs)(_e.s,{justifyContent:"space-between",alignItems:"center",className:Ah("header"),children:[(0,d.jsxs)(_e.s,{gap:1,children:[oh("preview.title"),(0,d.jsxs)(De.E,{color:"secondary",variant:"body-2",children:[a?`${oh("preview.truncated")} `:"","(",t,")"]}),(0,d.jsx)("div",{className:Ah("table-name"),children:e})]}),(0,d.jsxs)("div",{className:Ah("controls-left"),children:[(0,d.jsx)(wm,{disabled:Boolean(r)}),(0,d.jsx)(dn.$,{view:"flat-secondary",onClick:l,title:oh("preview.close"),children:(0,d.jsx)(Re.I,{data:qc.A,size:18})})]})]}),(0,d.jsx)(Am,{children:(0,d.jsx)("div",{className:Ah("result"),children:r?(0,d.jsx)("div",{className:Ah("message-container","error"),children:(0,Ve.Cb)(r)}):null===n||void 0===n?void 0:n()})})]})})}const kh=n.memo((function(e){const{className:t,value:a}=e,n=(0,b.YQ)();return(0,d.jsx)("span",{className:zh("cell",t),onClick:e=>n((0,L.DK)(e.target,a,"cell")),children:a})})),Oh=JSON.parse('{"empty":"Table is empty"}'),Mh=JSON.parse('{"empty":"\u0422\u0430\u0431\u043b\u0438\u0446\u0430 \u043f\u0443\u0441\u0442\u0430\u044f"}'),Lh=(0,he.g4)("ydb-query-result-table",{ru:Mh,en:Oh}),qh={...f.N3,stripedRows:!0,sortable:!1,displayIndices:!0},zh=(0,c.cn)("ydb-query-result-table"),Fh=(e,t)=>t,Uh=(e,t)=>t+1,Qh=e=>{const{columns:t,data:a,settings:s}=e,r=n.useMemo((()=>t?((e,t)=>{if(!e.length)return[];const a=null===t||void 0===t?void 0:t.slice(0,100);return e.map((({name:e,type:t})=>{const n=(0,Ve.nh)(t);return{name:e,width:It({data:a,name:e}),align:"number"===n?Pt.Ay.RIGHT:Pt.Ay.LEFT,render:({row:t})=>(0,d.jsx)(kh,{value:String(t[e])})}}))})(t,a):(e=>{if(null===e||void 0===e||!e.length)return[];const t=null===e||void 0===e?void 0:e.slice(0,100);return Object.keys(e[0]).map((a=>({name:a,width:It({data:t,name:a}),align:(0,Er.kf)(e[0][a])?Pt.Ay.RIGHT:Pt.Ay.LEFT,render:({row:e})=>(0,d.jsx)(kh,{value:String(e[a])})})))})(a)),[a,t]),i=n.useMemo((()=>({...qh,...s})),[s]);return Array.isArray(a)?r.length?(0,d.jsx)(ce.l,{data:a,columns:r,settings:i,rowKey:Fh,visibleRowIndex:Uh,wrapperClassName:zh("table-wrapper")}):(0,d.jsx)("div",{className:zh("message"),children:Lh("empty")}):null},$h=g.F.injectEndpoints({endpoints:e=>({sendQuery:e.query({queryFn:async({query:e,database:t,action:a,limitRows:n},{signal:s})=>{try{const r=await window.api.viewer.sendQuery({query:e,database:t,action:a,limit_rows:n},{signal:s,withRetries:!0});return(0,Ve.We)(r)?{error:r}:{data:(0,Ve.fW)(r)}}catch(r){return{error:r||new Error("Unauthorized")}}},providesTags:["PreviewData"]})}),overrideExisting:"throw"});function Bh({database:e,path:t,type:a}){var n,s,r;const i=`select * from \`${t}\` limit 101`,{currentData:o,isFetching:l,error:c}=$h.useSendQueryQuery({database:e,query:i,action:ft(a)?"execute-query":"execute-scan",limitRows:100},{refetchOnMountOrArgChange:!0}),u=l&&void 0===o,m=null!==(n=null===o||void 0===o||null===(s=o.resultSets)||void 0===s?void 0:s[0])&&void 0!==n?n:{};return(0,d.jsx)(Rh,{path:t,renderResult:()=>(0,d.jsx)(Qh,{data:m.result,columns:m.columns}),loading:u,error:c,truncated:m.truncated,quantity:null===(r=m.result)||void 0===r?void 0:r.length})}const Hh=JSON.parse('{"label_partition-id":"Partition ID: {{id}}","label_offsets-range":"offsets: {{start}} - {{end}}"}'),Wh=(0,he.g4)("ydb-preview",{en:Hh}),Gh=[{name:Hm,header:op[Hm],render:({row:{Offset:e}})=>(0,uu.isNil)(e)?f.Pd:e,sortable:!1},{name:Wm,header:op[Wm],render:({row:{CreateTimestamp:e,TimestampDiff:t}})=>(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Mp,{timestamp:e}),(0,d.jsx)("br",{}),(0,d.jsx)(qp,{value:t,baseColor:"secondary",variant:"body-1"})]}),width:200,sortable:!1},{name:Km,header:op[Km],render:({row:{Message:e,OriginalSize:t}})=>(0,d.jsx)(zp,{message:e,size:t}),width:500,sortable:!1},{name:Ym,header:op[Ym],render:({row:{StorageSize:e}})=>(0,d.jsx)(Fp,{size:e}),align:"right",width:100,sortable:!1}];function Vh({messages:e}){return(0,d.jsx)(ce.l,{data:e,columns:Gh,settings:f.N3,rowKey:(e,t)=>{var a;return null!==(a=e.Offset)&&void 0!==a?a:t},wrapperClassName:Ah("table-wrapper"),emptyDataMessage:"No data"})}function Jh({database:e,path:t}){var a,s;const{data:r,isLoading:i,error:o}=Ad.aD.useGetPartitionsQuery({path:t,database:e}),l=n.useMemo((()=>null===r||void 0===r?void 0:r[0]),[r]),c=n.useMemo((()=>{const a=null===l||void 0===l?void 0:l.partitionId;if(!l||(0,uu.isNil)(a))return Dd.hT;return{database:e,path:t,partition:String(a),limit:100,offset:(0,Er.y3)(l.endOffset)-100,message_size_limit:100}}),[e,t,l]),{currentData:u,error:m,isFetching:p}=ua.useGetTopicDataQuery(c),h=i||p&&void 0===u,v=n.useMemo((()=>{if(l)return{start:(0,Er.y3)(l.startOffset),end:(0,Er.y3)(l.endOffset)-1}}),[l]),g=n.useCallback((()=>{var e,t;return(0,d.jsxs)(_e.s,{direction:"column",children:[(0,d.jsxs)(_e.s,{className:Ah("partition-info"),alignItems:"center",gap:2,children:[!(0,uu.isNil)(null===l||void 0===l?void 0:l.partitionId)&&(0,d.jsx)(De.E,{variant:"body-2",children:Wh("label_partition-id",{id:l.partitionId})}),v&&(0,d.jsxs)(De.E,{variant:"body-2",color:"secondary",children:["(",Wh("label_offsets-range",v),")"]})]}),u&&(0,d.jsx)(Vh,{messages:null!==(e=null===(t=u.Messages)||void 0===t?void 0:t.toReversed())&&void 0!==e?e:[]})]})}),[v,l,u]),y=(0,Er.y3)(null===u||void 0===u?void 0:u.EndOffset)-(0,Er.y3)(null===u||void 0===u?void 0:u.StartOffset);return(0,d.jsx)(Rh,{path:t,renderResult:g,loading:h,error:o||m,truncated:y>100,quantity:null!==(a=null===u||void 0===u||null===(s=u.Messages)||void 0===s?void 0:s.length)&&void 0!==a?a:0})}function Kh(e){const{type:t,subType:a}=e,n=ct(t),s=t===Ye.EPathTypePersQueueGroup,r=a===Ze.EPathSubTypeStreamImpl,i=(0,D._p)();if(n)return(0,d.jsx)(Bh,{...e});if(s&&!r&&i)return(0,d.jsx)(Jh,{...e});return(0,d.jsx)(Rh,{...e,renderResult:()=>(0,d.jsx)("div",{className:Ah("message-container"),children:oh("preview.not-available")})})}const Yh=g.F.injectEndpoints({endpoints:e=>({cancelQuery:e.mutation({queryFn:async({queryId:e,database:t},{signal:a})=>{try{const n=await window.api.viewer.sendQuery({database:t,action:"cancel-query",query_id:e},{signal:a});if((0,Ve.We)(n))return{error:n};return{data:(0,Ve.fW)(n)}}catch(n){return{error:n}}}})}),overrideExisting:"throw"});var Zh=a(13066);async function Xh(e){var t;let a=1;const n=async()=>{if(!window.ydbEditor){if(!a)return!1;await new Promise((e=>{window.setTimeout(e,100)})),a-=1,n()}return!0};await n()?null===(t=window.ydbEditor)||void 0===t||t.trigger(void 0,"insertSnippetToEditor",e):console.error("Monaco editor not found")}function ev(e){return e.replace(/\$/g,"\\$")}const tv=e=>`-- docs: https://ydb.tech/en/docs/yql/reference/syntax/create_table\nCREATE TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}/my_row_table\``:"${1:my_row_table}"} (\n category_id Uint64 NOT NULL,\n id Uint64,\n expire_at Datetime,\n updated_on Datetime,\n name Text,\n \`binary-payload\` Bytes,\n attributes JsonDocument,\n -- uncomment to add a secondary index\n -- INDEX idx_row_table_id GLOBAL SYNC ON ( id ) COVER ( name, attributes ), -- Secondary indexes docs https://ydb.tech/en/docs/yql/reference/syntax/create_table#secondary_index\n PRIMARY KEY (category_id, id)\n) \nWITH (\n AUTO_PARTITIONING_BY_SIZE = ENABLED,\n AUTO_PARTITIONING_PARTITION_SIZE_MB = 2048,\n AUTO_PARTITIONING_BY_LOAD = ENABLED,\n AUTO_PARTITIONING_MIN_PARTITIONS_COUNT = 4,\n AUTO_PARTITIONING_MAX_PARTITIONS_COUNT = 1024\n -- uncomment to create a table with predefined partitions\n -- , UNIFORM_PARTITIONS = 4 -- The number of partitions for uniform initial table partitioning.\n -- The primary key's first column must have type Uint64 or Uint32.\n -- A created table is immediately divided into the specified number of partitions\n -- uncomment to launch read only replicas in every AZ\n -- , READ_REPLICAS_SETTINGS = 'PER_AZ:1' -- Enable read replicas for stale read, launch one replica in every availability zone\n -- uncomment to enable ttl\n -- , TTL = Interval("PT1H") ON expire_at -- Enable background deletion of expired rows https://ydb.tech/en/docs/concepts/ttl\n -- uncomment to create a table with a bloom filter\n -- , KEY_BLOOM_FILTER = ENABLED -- With a Bloom filter, you can more efficiently determine\n -- if some keys are missing in a table when making multiple single queries by the primary key.\n)`,av=e=>`-- docs: https://ydb.tech/en/docs/yql/reference/syntax/create_table#olap-tables\nCREATE TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}/my_column_table\``:"${1:my_column_table}"} (\n id Int64 NOT NULL,\n author Text,\n title Text,\n body Text,\n PRIMARY KEY (id)\n)\nPARTITION BY HASH(id)\nWITH (STORE = COLUMN)`,nv=()=>'-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-async-replication\nCREATE OBJECT secret_name (TYPE SECRET) WITH value="secret_value";\n\nCREATE ASYNC REPLICATION my_replication\nFOR ${1:} AS ${2:replica_table} --[, `/remote_database/another_table_name` AS `another_local_table_name` ...]\nWITH (\n CONNECTION_STRING="${3:grpcs://mydb.ydb.tech:2135/?database=/remote_database}",\n TOKEN_SECRET_NAME = "secret_name"\n -- ENDPOINT="mydb.ydb.tech:2135",\n -- DATABASE=`/remote_database`,\n -- USER="user",\n -- PASSWORD_SECRET_NAME="your_password"\n);',sv=()=>'-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-transfer\nCREATE OBJECT secret_name (TYPE SECRET) WITH value="secret_value";\n\n\\$l = (\\$x) -> {\n return [\n <|\n offset:\\$x._offset,\n message:\\$x._data\n |>\n ];\n};\n\nCREATE TRANSFER my_transfer\nFROM ${1:} TO ${2:} USING \\$l\nWITH (\n CONNECTION_STRING="${3:grpcs://mydb.ydb.tech:2135/?database=/remote_database}",\n TOKEN_SECRET_NAME = "secret_name"\n -- ENDPOINT="mydb.ydb.tech:2135",\n -- DATABASE=`/remote_database`,\n -- USER="user",\n -- PASSWORD_SECRET_NAME="your_password"\n);',rv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter_table/\n\nALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"}\n -- RENAME TO new_table_name\n -- DROP COLUMN some_existing_column\n\${2:ADD COLUMN numeric_column Int32};`,iv=e=>`-- documentation about partitioning https://ydb.tech/docs/en/concepts/datamodel/table#partitioning\n\nALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"} SET \n(\n AUTO_PARTITIONING_BY_LOAD = ENABLED, -- If a partition consumes more than 50% of the CPU for a few dozens of seconds, it is enqueued for splitting.\n AUTO_PARTITIONING_BY_SIZE = ENABLED, -- If a partition size exceeds the value specified by the AUTO_PARTITIONING_PARTITION_SIZE_MB parameter, it is enqueued for splitting.\n AUTO_PARTITIONING_PARTITION_SIZE_MB = 2048,\n AUTO_PARTITIONING_MIN_PARTITIONS_COUNT = 10, -- Partitions are merged only if their actual number exceeds the value specified by this parameter.\n AUTO_PARTITIONING_MAX_PARTITIONS_COUNT = 100 -- Partitions are split only if their number doesn't exceed the value specified by this parameter.\n)`,ov=e=>{var t;const a=null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${2:}";return`SELECT ${(null===e||void 0===e||null===(t=e.schemaData)||void 0===t?void 0:t.map((e=>{var t;return"`"+ev(null!==(t=e.name)&&void 0!==t?t:"")+"`"})).join(", "))||"${1:*}"}\nFROM ${a}\n${null!==e&&void 0!==e&&e.relativePath?"":"WHERE ${3:Key1 = 1}\nORDER BY ${4:Key1}\n"}LIMIT \${5:10};`},lv=e=>{var t;return`UPSERT INTO ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"}\n( ${(null===e||void 0===e||null===(t=e.schemaData)||void 0===t?void 0:t.map((e=>{var t;return`\`${ev(null!==(t=e.name)&&void 0!==t?t:"")}\``})).join(", "))||"${2:id, name}"} )\nVALUES ( ${null!==e&&void 0!==e&&e.schemaData?"${3: }":'${3:1, "foo"}'} );`},cv=e=>`DROP EXTERNAL TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:my_table}"};`,dv=e=>{const t=null===e||void 0===e?void 0:e.relativePath.split("/").slice(0,-1).join("/");return`CREATE EXTERNAL TABLE ${t?`\`${ev(t)}/my_external_table\``:"${1:}"} (\n column1 Int,\n column2 Int\n) WITH (\n DATA_SOURCE="${null!==e&&void 0!==e&&e.relativePath?`${ev(e.relativePath)}`:"${2:}"}",\n LOCATION="",\n FORMAT="json_as_string",\n \`file_pattern\`=""\n);`},uv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-topic\nCREATE TOPIC ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}/my_topic\``:"${1:my_topic}"} (\n CONSUMER consumer1,\n CONSUMER consumer2 WITH (read_from = Datetime('1970-01-01T00:00:00Z')) -- Sets up the message write time starting from which the consumer will receive data.\n -- Value type: Datetime OR Timestamp OR integer (unix-timestamp in the numeric format). \n -- Default value: now\n) WITH (\n min_active_partitions = 1, -- Minimum number of topic partitions.\n partition_count_limit = 0, -- Maximum number of active partitions in the topic. 0 is interpreted as unlimited.\n retention_period = Interval('PT18H'), -- Data retention period in the topic. Value type: Interval.\n retention_storage_mb = 0, -- Limit on the maximum disk space occupied by the topic data. \n -- When this value is exceeded, the older data is cleared, like under a retention policy. \n -- 0 is interpreted as unlimited.\n partition_write_speed_bytes_per_second = 1048576, -- Maximum allowed write speed per partition.\n partition_write_burst_bytes = 0 -- Write quota allocated for write bursts. \n -- When set to zero, the actual write_burst value is equalled to \n -- the quota value (this allows write bursts of up to one second).\n);`,mv=e=>`-- docs: https://ydb.tech/en/docs/yql/reference/syntax/alter_topic\nALTER TOPIC ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"}\n ADD CONSUMER new_consumer WITH (read_from = Datetime('1970-01-01T00:00:00Z')), -- Sets up the message write time starting from which the consumer will receive data.\n -- Value type: Datetime OR Timestamp OR integer (unix-timestamp in the numeric format).\n -- Default value: now\n ALTER CONSUMER consumer1 SET (read_from = Datetime('1970-01-01T00:00:00Z')),\n DROP CONSUMER consumer2,\n SET (\n min_active_partitions = 1, -- Minimum number of topic partitions.\n partition_count_limit = 0, -- Maximum number of active partitions in the topic. 0 is interpreted as unlimited.\n retention_period = Interval('PT18H'), -- Data retention period in the topic. Value type: Interval.\n retention_storage_mb = 0, -- Limit on the maximum disk space occupied by the topic data. \n -- When this value is exceeded, the older data is cleared, like under a retention policy. \n -- 0 is interpreted as unlimited.\n partition_write_speed_bytes_per_second = 1048576, -- Maximum allowed write speed per partition.\n partition_write_burst_bytes = 0 -- Write quota allocated for write bursts. \n -- When set to zero, the actual write_burst value is equalled to\n -- the quota value (this allows write bursts of up to one second).\n );`,pv=e=>`DROP TOPIC ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"};`,hv=e=>`CREATE VIEW ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}/my_view\``:"${1:my_view}"} WITH (security_invoker = TRUE) AS SELECT 1;`,vv=e=>`DROP VIEW ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"};`,gv=e=>`DROP ASYNC REPLICATION ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"};`,yv=e=>`DROP TRANSFER ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"};`,xv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter-async-replication\nALTER ASYNC REPLICATION ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"} SET (STATE = "DONE", FAILOVER_MODE = "FORCE");`,fv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter-transfer\n\n\\$l = (\\$x) -> {\n return [\n <|\n offset:\\$x._offset,\n message:\\$x._data\n |>\n ];\n};\n\nALTER TRANSFER ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"} \nSET USING \\$l;`,bv=e=>`ALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"} ADD INDEX \${2:index_name} GLOBAL ON (\${3:});`,jv=e=>{const t=null===e||void 0===e?void 0:e.relativePath.split("/").pop(),a=null===e||void 0===e?void 0:e.relativePath.split("/").slice(0,-1).join("/");return`ALTER TABLE ${a?`\`${ev(a)}\``:"${1:}"} DROP INDEX ${ev(null!==t&&void 0!==t?t:"")||"${2:}"};`},Tv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter_table/changefeed\nALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"} ADD CHANGEFEED \${2:changefeed_name} WITH (\n MODE = \${3:'UPDATES'}, -- KEYS_ONLY, UPDATES, NEW_IMAGE, OLD_IMAGE, or NEW_AND_OLD_IMAGES\n FORMAT = \${4:'JSON'}, -- JSON or DEBEZIUM_JSON\n VIRTUAL_TIMESTAMPS = \${5:TRUE}, -- true or false\n RETENTION_PERIOD = \${6:Interval('PT12H')}, -- Interval value, e.g., Interval('PT24H')\n -- TOPIC_MIN_ACTIVE_PARTITIONS: The number of topic partitions. By default, the number of topic partitions is equal to the number of table partitions\n INITIAL_SCAN = \${8:TRUE} -- true or false\n)\n\n-- MODE options:\n-- KEYS_ONLY: Only the primary key components and change flag are written.\n-- UPDATES: Updated column values that result from updates are written.\n-- NEW_IMAGE: Any column values resulting from updates are written.\n-- OLD_IMAGE: Any column values before updates are written.\n-- NEW_AND_OLD_IMAGES: A combination of NEW_IMAGE and OLD_IMAGE modes.`,Sv=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-group\nCREATE GROUP ${1:group_name}\n-- group_name: The name of the group. It may contain lowercase Latin letters and digits.",wv=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-user\nCREATE USER ${1:user_name} PASSWORD ${2:'password'}\n-- user_name: The name of the user. It may contain lowercase Latin letters and digits.\n-- option: The password of the user:\n -- PASSWORD 'password' creates a user with the password password. The ENCRYPTED option is always enabled.\n -- PASSWORD NULL creates a user with an empty password.",Nv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/delete\nDELETE FROM ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"}\nWHERE \${2:Key1 = 1};`,Ev=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/drop-group\nDROP GROUP ${1:}\n\n-- IF EXISTS: Suppress an error if the group doesn't exist.\n-- group_name: The name of the group to be deleted.",Cv=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/drop-user\nDROP USER ${1:}\n\n-- IF EXISTS: Suppress an error if the user doesn't exist.\n-- user_name: The name of the user to be deleted.",Pv=e=>`GRANT \${1:}\nON ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(null===e||void 0===e?void 0:e.relativePath)}\``:"${2:}"}\nTO \${3:}\n\n-- permission_name: The name of the access right to schema objects that needs to be assigned.\n-- path_to_scheme_object: The path to the schema object for which rights are being granted.\n-- role_name: The name of the user or group to whom rights on the schema object are being granted.\n-- WITH GRANT OPTION: Using this construct gives the user or group of users the right to manage access rights - \n-- to assign or revoke certain rights. This construct has functionality similar to granting \n-- the "ydb.access.grant" or GRANT right. A subject with the ydb.access.grant right cannot \n-- grant rights broader than they possess themselves.`,Iv=e=>`REVOKE \${1:}\nON ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(null===e||void 0===e?void 0:e.relativePath)}\``:"${2:}"}\nFROM \${3:}\n\n-- permission_name: The name of the access right to schema objects that needs to be revoked.\n-- path_to_scheme_object: The path to the schema object from which rights are being revoked.\n-- role_name: The name of the user or group from whom rights on the schema object are being revoked.\n-- GRANT OPTION FOR: Using this construct revokes the user's or group's right to manage access rights.\n-- All previously granted rights by this user remain in effect.\n-- This construct has functionality similar to revoking the "ydb.access.grant" or GRANT right.`,Dv=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/update\nUPDATE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"}\nSET \${2:Column1 = 'foo', Column2 = 'bar'}\nWHERE \${3:Key1 = 1};`,_v=e=>`DROP TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${ev(e.relativePath)}\``:"${1:}"};`,Av=JSON.parse('{"button.new-sql":"New query","action.create-row-table":"Create row table","action.create-column-table":"Create column table","action.create-external-table":"Create external table","action.upsert-to-table":"Upsert into table","action.update-table":"Update table","action.alter-table":"Alter table","action.select-rows":"Select from a table","action.delete-rows":"Delete rows","action.drop-table":"Drop table","action.add-index":"Add index","action.drop-index":"Drop index","action.drop-external-table":"Drop external table","menu.tables":"Tables","menu.topics":"Topics","menu.capture":"Change data capture","menu.replication":"Async replication","menu.transfer":"Transfer","menu.users":"Users","action.create-topic":"Create Topic","action.drop-topic":"Drop Topic","action.alter-topic":"Alter Topic","action.create-cdc-stream":"Create changefeed","action.create-async-replication":"Create async replication","action.create-transfer":"Create transfer","action.create-user":"Create user","action.create-group":"Create group","action.drop-user":"Drop user","action.drop-group":"Drop group","action.grant-privilege":"Grant privilege","action.revoke-privilege":"Revoke privilege","action.alter-async-replication":"Alter async replication","action.drop-async-replication":"Drop async replication","action.alter-transfer":"Alter transfer","action.drop-transfer":"Drop transfer"}'),Rv=(0,he.g4)("ydb-new-sql",{en:Av});function kv(){const e=(e=>{const t=t=>()=>{e(t())};return{createRowTable:t(tv),createColumnTable:t(av),createAsyncReplication:t(nv),alterAsyncReplication:t(xv),dropAsyncReplication:t(gv),createTransfer:t(sv),alterTransfer:t(fv),dropTransfer:t(yv),alterTable:t(rv),selectQuery:t(ov),upsertQuery:t(lv),createExternalTable:t(dv),dropExternalTable:t(cv),createTopic:t(uv),alterTopic:t(mv),dropTopic:t(pv),createView:t(hv),dropTable:t(_v),deleteRows:t(Nv),updateTable:t(Dv),createUser:t(wv),createGroup:t(Sv),createCdcStream:t(Tv),grantPrivilege:t(Pv),revokePrivilege:t(Iv),dropUser:t(Cv),dropGroup:t(Ev),addTableIndex:t(bv),dropTableIndex:t(jv)}})(Go(n.useCallback((e=>{Xh(e)}),[]))),t=[{text:Rv("menu.tables"),items:[{text:Rv("action.create-row-table"),action:e.createRowTable},{text:Rv("action.create-column-table"),action:e.createColumnTable},{text:Rv("action.create-external-table"),action:e.createExternalTable},{text:Rv("action.upsert-to-table"),action:e.upsertQuery},{text:Rv("action.update-table"),action:e.updateTable},{text:Rv("action.alter-table"),action:e.alterTable},{text:Rv("action.select-rows"),action:e.selectQuery},{text:Rv("action.delete-rows"),action:e.deleteRows},{text:Rv("action.drop-table"),action:e.dropTable},{text:Rv("action.drop-external-table"),action:e.dropExternalTable},{text:Rv("action.add-index"),action:e.addTableIndex},{text:Rv("action.drop-index"),action:e.dropTableIndex}]},{text:Rv("menu.topics"),items:[{text:Rv("action.create-topic"),action:e.createTopic},{text:Rv("action.alter-topic"),action:e.alterTopic},{text:Rv("action.drop-topic"),action:e.dropTopic}]},{text:Rv("menu.replication"),items:[{text:Rv("action.create-async-replication"),action:e.createAsyncReplication},{text:Rv("action.alter-async-replication"),action:e.alterAsyncReplication},{text:Rv("action.drop-async-replication"),action:e.dropAsyncReplication}]},{text:Rv("menu.transfer"),items:[{text:Rv("action.create-transfer"),action:e.createTransfer},{text:Rv("action.alter-transfer"),action:e.alterTransfer},{text:Rv("action.drop-transfer"),action:e.dropTransfer}]},{text:Rv("menu.capture"),items:[{text:Rv("action.create-cdc-stream"),action:e.createCdcStream}]},{text:Rv("menu.users"),items:[{text:Rv("action.create-user"),action:e.createUser},{text:Rv("action.create-group"),action:e.createGroup},{text:Rv("action.drop-user"),action:e.dropUser},{text:Rv("action.drop-group"),action:e.dropGroup},{text:Rv("action.grant-privilege"),action:e.grantPrivilege},{text:Rv("action.revoke-privilege"),action:e.revokePrivilege}]}];return(0,d.jsx)(_o.r,{items:t,renderSwitcher:e=>(0,d.jsxs)(dn.$,{...e,children:[Rv("button.new-sql"),(0,d.jsx)(dn.$.Icon,{children:(0,d.jsx)(Zh.A,{})})]}),popupProps:{placement:"top"}})}const Ov=g.F.injectEndpoints({endpoints:e=>({getCodeAssistSuggestions:e.query({queryFn:async e=>{try{if(window.api.codeAssist){return{data:await window.api.codeAssist.getCodeAssistSuggestions(e)}}throw new Error("Method is not implemented.")}catch{return{data:{items:[]}}}}}),acceptSuggestion:e.mutation({queryFn:async e=>{try{if(window.api.codeAssist){return{data:await window.api.codeAssist.sendCodeAssistTelemetry({Accepted:{AcceptedText:e.acceptedText,ConvertedText:e.acceptedText,Timestamp:Date.now(),RequestId:e.requestId}})}}throw new Error("Method is not implemented.")}catch(t){return{error:t}}}}),discardSuggestion:e.mutation({queryFn:async e=>{try{if(window.api.codeAssist){return{data:await window.api.codeAssist.sendCodeAssistTelemetry({Discarded:{RequestId:e.requestId,Timestamp:Date.now(),DiscardReason:"OnCancel",DiscardedText:e.suggestionText,CacheHitCount:e.hitCount}})}}throw new Error("Method is not implemented.")}catch(t){return{error:t}}}}),ignoreSuggestion:e.mutation({queryFn:async e=>{try{if(window.api.codeAssist){return{data:await window.api.codeAssist.sendCodeAssistTelemetry({Ignored:{RequestId:e.requestId,Timestamp:Date.now(),IgnoredText:e.suggestionText}})}}throw new Error("Method is not implemented.")}catch(t){return{error:t}}}}),sendUserQueriesData:e.mutation({queryFn:async e=>{try{if(window.api.codeAssist){return{data:await window.api.codeAssist.sendCodeAssistOpenTabs(e)}}throw new Error("Method is not implemented.")}catch(t){return{error:t}}}})}),overrideExisting:"throw"}),Mv={automaticLayout:!0,selectOnLineNumbers:!0,minimap:{enabled:!1},fixedOverflowWidgets:!0};const Lv=new class{constructor(){this.query=void 0,this.query=null}registerQuery(e){this.query=e}abortQuery(){this.query&&(this.query.abort(),this.query=null)}};var qv=a(54503),zv=a(90851),Fv=a(27738),Uv=a(1155);const Qv=(0,c.cn)("ydb-query-settings-description"),$v=({querySettings:e,prefix:t})=>(0,d.jsxs)("div",{className:Qv("message"),children:[t,Object.entries(e).map((([e,t],a,n)=>(0,d.jsxs)("span",{className:Qv("description-item"),children:[`${e}: ${t}`,a(0,d.jsxs)(dn.$,{...e,className:Bv("run-button"),children:[(0,d.jsx)(Re.I,{data:qv.A,size:16}),oh("action.run")]}),Stop:e=>(0,d.jsxs)(dn.$,{...e,className:Bv("stop-button",{error:e.error}),children:[(0,d.jsx)(Re.I,{data:Ie.A,size:16}),oh("action.stop")]}),Explain:e=>(0,d.jsxs)(dn.$,{...e,className:Bv("explain-button"),children:[(0,d.jsx)(Re.I,{data:zv.A,size:16}),oh("action.explain")]}),Settings:({onClick:e,isLoading:t})=>{const{changedCurrentSettings:a,changedCurrentSettingsDescriptions:n}=wh(),s=a.length>0?{view:"outlined-info",selected:!0}:null;return(0,d.jsx)(Uv.m,{disabled:0===a.length,content:(0,d.jsx)($v,{prefix:oh("gear.tooltip"),querySettings:n}),openDelay:0,placement:["top-start"],children:(0,d.jsxs)(dn.$,{onClick:e,loading:t,className:Bv("gear-button"),...s,children:[(0,d.jsx)(Re.I,{data:Fv.A,size:16}),s?(0,d.jsxs)("div",{className:Bv("changed-settings"),children:["(",a.length,")"]}):null]})})}},Wv=(0,c.cn)("ydb-query-editor-controls"),Gv=({type:e,isHighlighted:t,isLoading:a,isStoppable:n,controlsDisabled:s,onActionClick:r,renderStopButton:i})=>{if(n&&a&&t)return i();const o="run"===e?Hv.Run:Hv.Explain;return(0,d.jsx)(o,{onClick:r,disabled:s,loading:a,view:t?"action":void 0})},Vv=({disabled:e,isLoading:t,highlightedAction:a,queryId:s,tenantName:r,isStreamingEnabled:i,handleSendExecuteClick:o,onSettingsButtonClick:l,handleGetExplainQueryClick:c})=>{const u=(0,b.N4)(So.Wp),[m,p]=Yh.useCancelQueryMutation(),[h,v]=n.useState(t),g=n.useRef(null),y=n.useRef(null),[x,f]=n.useState(!1),j=n.useCallback((async()=>{try{i?Lv.abortQuery():s&&await m({queryId:s,database:r}).unwrap()}catch{qe({name:"stop-error",title:"",content:oh("toaster.stop-error"),type:"error",autoHiding:5e3}),f(!0),y.current&&window.clearTimeout(y.current),y.current=window.setTimeout((()=>{f(!1)}),500)}}),[i,s,m,r]),T="execute"===a,S="explain"===a,w=n.useCallback((()=>{g.current&&window.clearTimeout(g.current),v(!1),g.current=window.setTimeout((()=>{v(!0)}),400)}),[]),N=n.useCallback((()=>{o(u),w()}),[o,u,w]),E=n.useCallback((()=>{c(u),w()}),[c,u,w]);n.useEffect((()=>()=>{g.current&&window.clearTimeout(g.current),y.current&&window.clearTimeout(y.current)}),[]);const C=e||!u,P=()=>(0,d.jsx)(Hv.Stop,{loading:p.isLoading,error:x,onClick:j,view:"action"});return(0,d.jsxs)("div",{className:Wv(),children:[(0,d.jsxs)("div",{className:Wv("left"),children:[(0,d.jsx)(Gv,{type:"run",isHighlighted:T,isLoading:t,isStoppable:h,controlsDisabled:C,onActionClick:N,renderStopButton:P}),(0,d.jsx)(Gv,{type:"explain",isHighlighted:S,isLoading:t,isStoppable:h,controlsDisabled:C,onActionClick:E,renderStopButton:P}),(0,d.jsx)(Hv.Settings,{onClick:l,isLoading:t})]}),(0,d.jsxs)("div",{className:Wv("right"),children:[(0,d.jsx)(kv,{}),(0,d.jsx)(zo,{buttonProps:{disabled:e}})]})]})};var Jv=a(64280),Kv=a(5744),Yv=a(80953);function Zv(e){var t;if(function(e){return"object"===typeof e&&null!==e&&"name"in e&&"AbortError"===e.name}(e))return!0;if((0,j.cH)(e)&&e.isCancelled)return!0;const a=(0,Ve.KH)(e);return(0,Ve.We)(a)&&"Query was cancelled"===(null===(t=a.error)||void 0===t?void 0:t.message)}const Xv=(0,c.cn)("kv-query-execution-status"),eg=({className:e,error:t,loading:a})=>{let s,r,i,o;const{startTime:l,endTime:c}=(0,b.N4)(So.$u),[u,m]=n.useState(l?(c||Date.now())-l:0),p=Zv(t),h=n.useCallback((()=>{if(l){const e=c||Date.now();m(e-l)}}),[c,l]);n.useEffect((()=>{let e;return h(),a?e=setInterval(h,f.KF):clearInterval(e),()=>{clearInterval(e)}}),[a,h]);const v=n.useMemo((()=>u>f.Jg*f.KF?(0,Ce.p0)(u).format("hh:mm:ss"):(0,Ce.p0)(u).format("mm:ss")),[u]);if(a)i="info",o="info-heavy",s=(0,d.jsx)(Yv.t,{size:"xs"}),r="Running";else if((0,j.F0)(t)&&"ECONNABORTED"===t.code)i="danger",o="danger-heavy",s=(0,d.jsx)(Re.I,{data:Jv.A}),r="Connection aborted";else if(p)i="warning",o="warning-heavy",s=(0,d.jsx)(Re.I,{data:Ie.A,className:Xv("result-status-icon",{error:!0})}),r="Stopped";else{const e=Boolean(t);i=e?"danger":"success",o=e?"danger-heavy":"positive-heavy",s=(0,d.jsx)(Re.I,{data:e?Gi.A:Kv.A,className:Xv("result-status-icon",{error:e})}),r=e?"Failed":"Completed"}return(0,d.jsx)(Tt.J,{theme:i,size:"m",className:Xv(null,e),icon:s,value:v,children:(0,d.jsx)(De.E,{color:o,children:r})})};var tg=a(6156);const ag=(0,c.cn)("ydb-query-settings-banner");function ng(){const{isBannerShown:e,changedLastExecutionSettingsDescriptions:t,closeBanner:a}=wh();return e?(0,d.jsx)(tg.F,{className:ag(),theme:"info",align:"baseline",style:{paddingTop:11,paddingBottom:11},message:(0,d.jsx)($v,{prefix:oh("banner.query-settings.message"),querySettings:t}),onClose:a}):null}const sg=(0,c.cn)("ydb-query-stopped-banner");function rg(){const[e,t]=(0,b.iK)(f.J0),a=n.useCallback((()=>{t(!0)}),[t]);return e?null:(0,d.jsx)(tg.F,{className:sg(),theme:"normal",align:"center",style:{paddingTop:11,paddingBottom:11},message:(0,d.jsx)("div",{className:sg("message"),children:oh("banner.query-stopped.message")}),layout:"horizontal",actions:(0,d.jsx)(tg.F.Actions,{children:(0,d.jsx)(tg.F.Action,{view:"normal",onClick:a,children:oh("banner.query-stopped.never-show")})})})}function ig(e){return e.replaceAll("\\","\\\\").replaceAll("\n","\\n").replaceAll("\r","\\r").replaceAll("\t","\\t")}var og=a(6376);const lg=(0,c.cn)("ydb-query-ast"),cg={automaticLayout:!0,selectOnLineNumbers:!0,readOnly:!0,minimap:{enabled:!1},wrappingIndent:"indent"};function dg({ast:e,theme:t}){return(0,d.jsx)("div",{className:lg(),children:(0,d.jsx)(og.default,{language:"s-expression",value:e,options:cg,theme:`vs-${t}`})})}var ug=a(73253);function mg(e){const t=n.useRef(null),a=n.useId(),{data:s,opts:r,shapes:i}=e;return n.useEffect((()=>{const e=t.current;if(!e)return;e.innerHTML="",e.style.setProperty("width","100vw"),e.style.setProperty("height","100vh");const a=(0,ug.og)(e.id,s,r,i);return a.render(),e.style.setProperty("width","100%"),e.style.setProperty("height","100%"),()=>{a.destroy()}}),[s,r,i]),(0,d.jsx)("div",{id:a,ref:t,style:{overflow:"auto"}})}const pg={renderNodeTitle:e=>{const t=e.name.split("|");return t.length>1?t[1]:e.name},textOverflow:"normal",initialZoomFitsCanvas:!0},hg={node:ug.SO};function vg(e){return(0,d.jsx)(mg,{...e,opts:pg,shapes:hg})}const gg=JSON.parse('{"description.graph-is-not-supported":"Graph can not be rendered","description.empty-result":"There is no {{activeSection}} for the request","action.result":"Result","action.stats":"Stats","action.schema":"Computation Graph","action.explain-plan":"Explain","action.json":"JSON","action.ast":"AST","action.copy":"Copy {{activeSection}}","trace":"Trace","title.truncated":"Truncated","title.result":"Result","tooltip_actions":"Actions","text_open-execution-plan":"Open Execution Plan","text_open-execution-plan_description":"New tab","text_download":"Download Execution Plan","text_download_description":"SVG","text_diagnostics":"Download Diagnostics","text_diagnostics_description":"JSON","text_error-plan-svg":"Error: {{error}}","error.title":"Query Failed","error.description":"An error occurred, please see the Result tab for details","stopped.title":"Query stopped","stopped.description":"Query was stopped"}'),yg=(0,he.g4)("ydb-execute-result",{en:gg}),xg=(0,c.cn)("ydb-query-result-stub-message");function fg({message:e}){return(0,d.jsx)("div",{className:xg(null),children:e})}const bg=(0,c.cn)("ydb-query-explain-graph");function jg({explain:e={},theme:t}){const{links:a,nodes:s}=e,r=n.useMemo((()=>({links:a,nodes:s})),[a,s]);return function(e){return Boolean(e.links&&e.nodes&&e.nodes.length)}(r)?(0,d.jsx)("div",{className:bg("canvas-container"),children:(0,d.jsx)(vg,{data:r},t)}):(0,d.jsx)(fg,{message:yg("description.graph-is-not-supported")})}var Tg=a(7450);const Sg=(0,c.cn)("query-info-dropdown");var wg=a(112);const Ng=g.F.injectEndpoints({endpoints:e=>({planToSvgQuery:e.query({queryFn:async({plan:e,database:t},{signal:a})=>{try{return{data:await window.api.viewer.planToSvg({database:t,plan:e},{signal:a})}}catch(n){return{error:n}}}})}),overrideExisting:"throw"}),Eg=JSON.parse('{"unknown-error":"An unknown error occurred"}'),Cg=(0,he.g4)("ydb-errors",{en:Eg});function Pg({title:e,description:t}){return(0,d.jsxs)("div",{className:Sg("menu-item-content"),children:[(0,d.jsx)(De.E,{variant:"body-1",children:e}),(0,d.jsx)(De.E,{variant:"body-1",color:"secondary",children:t})]})}function Ig({queryResultsInfo:e,database:t,hasPlanToSvg:a,error:s}){const[r,i]=n.useState(null),[o,{isLoading:l}]=Ng.useLazyPlanToSvgQueryQuery();n.useEffect((()=>()=>{r&&URL.revokeObjectURL(r)}),[r]);return{isLoading:l,items:n.useMemo((()=>{const n=[],l=e.plan;if(l&&a){const e=()=>r?Promise.resolve(r):o({plan:l,database:t}).unwrap().then((e=>{const t=new Blob([e],{type:"image/svg+xml"}),a=URL.createObjectURL(t);return i(a),a})).catch((e=>{const t=function(e){if("string"===typeof e)return e;if(!e)return Cg("unknown-error");if((0,j.TX)(e))return e.message;if((0,j.cH)(e)){if(e.data&&"object"===typeof e.data&&"message"in e.data&&"string"===typeof e.data.message)return e.data.message;if("string"===typeof e.data)return e.data}return e instanceof Error?e.message:JSON.stringify(e)}(e);return qe({title:yg("text_error-plan-svg",{error:t}),name:"plan-svg-error",type:"error"}),null})),a=()=>{e().then((e=>{e&&window.open(e,"_blank")}))},s=()=>{e().then((e=>{e&&pp(e,"query-plan.svg")}))};n.push([{text:(0,d.jsx)(Pg,{title:yg("text_open-execution-plan"),description:yg("text_open-execution-plan_description")}),icon:(0,d.jsx)(wg.A,{className:Sg("icon")}),action:a,className:Sg("menu-item")},{text:(0,d.jsx)(Pg,{title:yg("text_download"),description:yg("text_download_description")}),icon:(0,d.jsx)(up.A,{className:Sg("icon")}),action:s,className:Sg("menu-item")}])}if(e){const a=()=>{const a=s?(0,Ve.KH)(s):void 0;((e,t)=>{const a=JSON.stringify(e,null,2);hp(a,`${t}.json`,"application/json")})({...e,database:t,...a&&{error:a}},`query-diagnostics-${(new Date).getTime()}`)};n.push([{text:(0,d.jsx)(Pg,{title:yg("text_diagnostics"),description:yg("text_diagnostics_description")}),icon:(0,d.jsx)(up.A,{className:Sg("icon")}),action:a,className:Sg("menu-item")}])}return n}),[e,a,r,o,t,s])}}function Dg({queryResultsInfo:e,database:t,hasPlanToSvg:a,error:n}){const{isLoading:s,items:r}=Ig({queryResultsInfo:e,database:t,hasPlanToSvg:a,error:n});return r.length?(0,d.jsx)(_o.r,{popupProps:{placement:["bottom-end","left"]},switcherWrapperClassName:Sg("query-info-switcher-wrapper"),renderSwitcher:e=>(0,d.jsx)(Ae.m,{title:yg("tooltip_actions"),children:(0,d.jsx)(dn.$,{view:"flat-secondary",loading:s,disabled:s,...e,children:(0,d.jsx)(dn.$.Icon,{children:(0,d.jsx)(Tg.A,{})})})}),items:r,size:"xl"}):null}const _g=(0,c.cn)("ydb-query-json-viewer");function Ag({data:e}){const t=Sn(e);return(0,d.jsx)("div",{className:_g(),children:(0,d.jsx)("div",{className:_g("tree"),children:(0,d.jsx)(os,{value:t})})})}var Rg=a(56999);const kg=(0,c.cn)("ydb-query-result-error");function Og({error:e}){const t=(0,Ve.KH)(e);return!t||Zv(e)?null:(0,j.TX)(e)?(0,d.jsx)("div",{className:kg("message"),children:e.message}):"object"===typeof t?(0,d.jsx)("div",{className:kg("message"),children:(0,d.jsx)(Rg.O,{data:t})}):(0,d.jsx)("div",{className:kg("message"),children:t})}const Mg=(0,c.cn)("ydb-query-result-sets-viewer");function Lg(e){const{selectedResultSet:t,setSelectedResultSet:a,resultSets:n,error:s}=e,r=null===n||void 0===n?void 0:n[t];return(0,d.jsxs)("div",{className:Mg("result-wrapper"),children:[e.error?(0,d.jsx)(Og,{error:s}):null,null!==n&&void 0!==n&&n.length?(null===n||void 0===n?void 0:n.length)>1?(()=>{const e=(null===n||void 0===n?void 0:n.map(((e,t)=>{var a,s;const r=null===n||void 0===n?void 0:n[t];return{id:String(t),title:(0,d.jsxs)(_e.s,{gap:2,alignItems:"center",children:[(0,d.jsx)(De.E,{children:`Result #${t+1}${null!==n&&void 0!==n&&null!==(a=n[t])&&void 0!==a&&a.truncated?"(T)":""}`}),(0,d.jsx)(De.E,{color:"secondary",children:(null===(s=r.result)||void 0===s?void 0:s.length)||0})]})}})))||[];return(0,d.jsx)(w.t,{className:Mg("tabs"),size:"l",items:e,activeTab:String(t),onSelectTab:e=>a(Number(e))})})():(()=>{var e;const t=null===n||void 0===n?void 0:n[0];return(0,d.jsxs)(_e.s,{gap:2,alignItems:"center",className:Mg("title"),children:[(0,d.jsx)(De.E,{children:null!==t&&void 0!==t&&t.truncated?"Truncated":"Result"}),(0,d.jsx)(De.E,{color:"secondary",children:(null===t||void 0===t||null===(e=t.result)||void 0===e?void 0:e.length)||0})]})})():null,r?(0,d.jsx)("div",{className:Mg("result"),children:(0,d.jsx)(Qh,{settings:e.tableSettings,data:r.result,columns:r.columns})}):null]})}var qg=a(36590),zg=a(79737),Fg=a(79685);const Ug=(0,c.cn)("ydb-query-simplified-plan");function Qg({value:e,formatter:t}){if(!(0,Er.kf)(e))return;const a=t(Number(e));return(0,d.jsx)("div",{className:Ug("metrics-cell"),children:a})}var $g=a(33705);const Bg={Table:"var(--g-color-text-info)",Predicate:"var(--g-color-text-positive)",Condition:"var(--g-color-text-utility)"};function Hg(e){return e in Bg?Bg[e]:"var(--g-color-text-secondary)"}function Wg(e={}){const t=[],a=Object.entries(e);if(1===a.length){const e=a[0][1],n=Hg(a[0][0]);t.push((0,d.jsx)("span",{style:{color:n},children:(0,q.vN)(e)},"param"))}else{const a=function(e){const t=[],{Table:a,Predicate:n,Condition:s,...r}=e;return a&&t.push(["Table",a]),n&&t.push(["Predicate",n]),s&&t.push(["Condition",s]),t.concat(Object.entries(r))}(e);for(let e=0;e0&&t.push(", "),t.push((0,d.jsxs)("span",{style:{color:r},children:[n,": ",(0,q.vN)(s)]},e))}}return t}function Gg({params:e}){return e?(0,d.jsxs)("span",{className:Ug("operation-params"),children:["(",Wg(e),")"]}):null}function Vg({modifiers:e,left:t}){return(0,d.jsx)("div",{className:Ug("divider",e),style:{left:t}})}function Jg({row:e,depth:t=0,params:a}){const{name:s,operationParams:r,lines:i=""}=a,o=e.getLeafRows().length>0&&e.getIsExpanded(),l=n.useMemo((()=>function(e,t){const a=e.split(".").map(Number),n=[];for(let s=0;se<1e8?(0,Fg.p)(e).format():(0,Er.z0)(e,1)})}const Yg=[{accessorKey:"name",accessorFn:function(e){return{name:e.name,operationParams:e.operationParams,lines:e.lines}},header:()=>(0,d.jsx)(zg.A,{children:"Operation"}),size:600,cell:e=>(0,d.jsx)(Jg,{row:e.row,depth:e.row.depth,params:e.getValue()})},{accessorKey:"aCpu",header:()=>(0,d.jsx)(zg.A,{children:"A-Cpu"}),size:90,minSize:90,cell:function(e){return(0,d.jsx)(Qg,{value:e.getValue(),formatter:e=>(0,ze.Xo)(Math.round(e))})},meta:{align:"right",verticalAlign:"top"}},{accessorKey:"aRows",header:()=>(0,d.jsx)(zg.A,{children:"A-Rows"}),size:90,minSize:90,cell:Kg,meta:{align:"right",verticalAlign:"top"}},{accessorKey:"eCost",header:()=>(0,d.jsx)(zg.A,{children:"E-Cost"}),size:90,minSize:90,cell:Kg,meta:{align:"right",verticalAlign:"top"}},{accessorKey:"eRows",header:()=>(0,d.jsx)(zg.A,{children:"E-Rows"}),size:90,minSize:90,cell:Kg,meta:{align:"right",verticalAlign:"top"}},{accessorKey:"eSize",header:()=>(0,d.jsx)(zg.A,{children:"E-Size"}),size:90,minSize:90,cell:Kg,meta:{align:"right",verticalAlign:"top"}}];function Zg({plan:e}){const t=n.useMemo((()=>function(e,t=""){if(!e)return[];const a=[{items:e,prefix:t,parentIndex:-1,parentArray:[]}],n=[];for(;a.length>0;){const{items:e,prefix:t,parentIndex:s,parentArray:r}=a.pop(),i=[];for(let n=0;ne.children,enableExpanding:!0,onExpandedChange:s,state:{expanded:a},enableColumnResizing:!0,columnResizeMode:"onChange"});return(0,d.jsx)(zg.X,{wrapperClassName:Ug(),table:r,stickyHeader:!0,width:"max"})}function Xg({traceId:e}){const{traceView:t}=(0,xi.Zd)(),a=null!==t&&void 0!==t&&t.url?(n=t.url,s={traceId:e},n.replace(/\${(\w+)}/g,((e,t)=>s[t]||e))):"";var n,s;return a?(0,d.jsxs)(dn.$,{view:"flat-info",href:a,target:"_blank",children:[yg("trace"),(0,d.jsx)(dn.$.Icon,{children:(0,d.jsx)(wg.A,{})})]}):null}const ey=(0,c.cn)("ydb-query-result"),ty="result",ay="schema",ny="simplified",sy="json",ry="stats",iy="ast",oy={get result(){return yg("action.result")},get schema(){return yg("action.schema")},get simplified(){return yg("action.explain-plan")},get json(){return yg("action.json")},get stats(){return yg("action.stats")},get ast(){return yg("action.ast")}},ly=["result","schema","simplified","stats"],cy=["schema","simplified","json","ast"];function dy({result:e,resultType:t="execute",isResultsCollapsed:a,theme:s,tenantName:r,queryText:i,tableSettings:l,onCollapseResults:c,onExpandResults:u}){var m;const p=(0,b.YQ)(),h="execute"===t,v="explain"===t,[g,y]=n.useState(0),[x,j]=n.useState((()=>h?ty:ay)),[T]=(0,b.iK)(f.lr),{error:S,isLoading:w,data:N={}}=e,{preparedPlan:E,simplifiedPlan:C,stats:P,resultSets:I,ast:D}=N;n.useEffect((()=>{"execute"!==t||ly.includes(x)||j("result"),"explain"!==t||cy.includes(x)||j("schema")}),[x,t]);const _=n.useMemo((()=>{let e=[];return h?e=ly:v&&(e=cy),e.map((e=>({value:e,content:oy[e]})))}),[h,v]);n.useEffect((()=>()=>{p((0,Sm.sM)())}),[p]);const A=e=>{j(e)},R=()=>{switch(x){case ty:{var e;const t=null===N||void 0===N||null===(e=N.resultSets)||void 0===e?void 0:e[g],a=function(e){if(null===e||void 0===e||!e.length)return"";const t=Object.keys(e[0]),a=[t.map(ig).join("\t")];for(const n of e){const e=[];for(const a of t){const t=n[a];e.push(ig("object"===typeof t?JSON.stringify(t):`${t}`))}a.push(e.join("\t"))}return a.join("\n")}(null===t||void 0===t?void 0:t.result);return a}case sy:return null===E||void 0===E?void 0:E.pristine;case ny:return null===C||void 0===C?void 0:C.pristine;case ry:return P;case iy:return D;default:return}},k=()=>{if(w)return null;const e=R(),t=(0,q.vN)(e);return t?(0,d.jsx)(cn.b,{text:t,view:"flat-secondary",title:yg("action.copy",{activeSection:x})}):null},O=()=>(0,d.jsx)(fg,{message:yg("description.empty-result",{activeSection:oy[x]})}),M=e=>(0,d.jsxs)(_e.s,{justifyContent:"center",alignItems:"center",width:"100%",gap:8,children:[(0,d.jsx)(Kc.v,{name:"error",className:ey("illustration")}),(0,d.jsxs)(_e.s,{direction:"column",gap:2,children:[(0,d.jsx)(De.E,{variant:"subheader-2",children:yg(e?"stopped.title":"error.title")}),(0,d.jsx)(De.E,{color:"complementary",children:yg(e?"stopped.description":"error.description")})]})]}),L=Zv(S);return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)("div",{className:ey("controls"),children:[(0,d.jsxs)("div",{className:ey("controls-left"),children:[_.length&&x?(0,d.jsx)(du.a,{options:_,value:x,onUpdate:A}):null,(0,d.jsx)(eg,{error:S,loading:w}),null!==N&&void 0!==N&&N.traceId&&h?(0,d.jsx)(Xg,{traceId:N.traceId}):null]}),(0,d.jsxs)("div",{className:ey("controls-right"),children:[w||Zv(S)?null:(0,d.jsx)(Dg,{queryResultsInfo:{queryText:i,ast:N.ast,stats:N.stats,plan:N.plan},error:S,database:r,hasPlanToSvg:Boolean((null===N||void 0===N?void 0:N.plan)&&T&&h)}),k(),(0,d.jsx)(wm,{}),(0,d.jsx)(_h,{onCollapse:c,onExpand:u,isCollapsed:a,initialDirection:"bottom"})]})]}),w||L?null:(0,d.jsx)(ng,{}),L&&null!==(m=N.resultSets)&&void 0!==m&&m.length?(0,d.jsx)(rg,{}):null,(0,d.jsx)(o.r,{loading:w&&(!N.resultSets||"result"!==x),children:(0,d.jsx)(Am,{className:ey("result"),children:(()=>{const e=Zv(S);return x===ty?!S||!e||null!==I&&void 0!==I&&I.length?(0,d.jsx)(Lg,{resultSets:I,error:S,selectedResultSet:g,tableSettings:l,setSelectedResultSet:y}):M(e):S?h||e?M(e):(0,d.jsx)(Og,{error:S}):x===ay?null!==E&&void 0!==E&&null!==(t=E.nodes)&&void 0!==t&&t.length?(0,d.jsx)(jg,{theme:s,explain:E}):O():x===sy?null!==E&&void 0!==E&&E.pristine?(0,d.jsx)(Ag,{data:null===E||void 0===E?void 0:E.pristine}):O():x===ny?null!==C&&void 0!==C&&null!==(a=C.plan)&&void 0!==a&&a.length?(0,d.jsx)(Zg,{plan:C.plan}):O():x===ry?P?(0,d.jsx)(Ag,{data:P}):O():x===iy?D?(0,d.jsx)(dg,{ast:D,theme:s}):O():null;var t,a})()})})]})}var uy=a(16122),my=a(23971);const py=()=>-1,hy=(0,c.cn)("ydb-query-settings-select");function vy(e){return(0,d.jsx)("div",{className:hy("selector"),children:(0,d.jsx)(A.l,{id:e.id,disabled:e.disabled,options:e.settingOptions,value:[e.setting],onUpdate:t=>{e.onUpdateSetting(t[0])},getOptionHeight:py,popupClassName:hy("popup"),renderOption:e=>(0,d.jsxs)("div",{className:hy("item",{type:e.value}),children:[(0,d.jsxs)("div",{className:hy("item-title"),children:[e.content,e.isDefault?hh("description.default"):""]}),e.text&&(0,d.jsx)("span",{className:hy("item-description"),children:e.text})]}),width:"max"})})}const gy=(0,c.cn)("ydb-timeout-label");function yy({isDisabled:e,isChecked:t,onToggle:a}){const[n]=(0,b.iK)(f.kO);return n?(0,d.jsxs)("div",{className:gy("switch-title"),children:[(0,d.jsx)(ta.d,{disabled:e,checked:t,onUpdate:a,className:gy("switch"),content:fh.timeout.title}),e&&(0,d.jsx)(zm.H,{className:gy("question-icon"),placement:"bottom-start",children:hh("form.timeout.disabled")})]}):(0,d.jsx)("label",{htmlFor:"timeout",className:gy("label-title"),children:fh.timeout.title})}const xy=(0,c.cn)("ydb-query-settings-timeout");function fy({id:e,value:t,onChange:a,onToggle:s,validationState:r,errorMessage:i,isDisabled:o}){const l=n.useCallback((e=>{const t=e.target.value?Number(e.target.value):void 0;a(t)}),[a]),c=null!==t;return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(yy,{isDisabled:o,isChecked:c,onToggle:s}),c&&(0,d.jsx)("div",{className:xy("control-wrapper"),children:(0,d.jsx)(On.k,{id:e,type:"number",value:(null===t||void 0===t?void 0:t.toString())||"",onChange:l,className:xy("input"),placeholder:"60",validationState:r,errorMessage:i,errorPlacement:"inside",endContent:(0,d.jsx)("span",{className:xy("postfix"),children:hh("form.timeout.seconds")})})})]})}const by=(0,c.cn)("ydb-query-settings-dialog");function jy(){const e=(0,b.YQ)(),t=(0,b.N4)(Ao.xM),[a,s]=(0,b.XS)(),r=n.useCallback((()=>{e((0,Ao.NJ)("idle"))}),[e]),i=n.useCallback((e=>{s(e),r()}),[r,s]);return(0,d.jsxs)(Fn.l,{open:"settings"===t,size:"s",onClose:r,className:by(),hasCloseButton:!1,children:[(0,d.jsx)(Fn.l.Header,{caption:hh("action.settings")}),(0,d.jsx)(Ty,{initialValues:a,onSubmit:i,onClose:r})]})}function Ty({initialValues:e,onSubmit:t,onClose:a}){const{control:n,handleSubmit:s,setValue:r,watch:i,formState:{errors:o}}=(0,my.mN)({defaultValues:e,resolver:(0,uy.u)(Ve.id)}),[l]=(0,b.iK)(f.lr),c=(0,D.Oi)(),u=i("timeout"),m=i("queryMode");return(0,d.jsxs)("form",{onSubmit:s(t),children:[(0,d.jsxs)(Fn.l.Body,{className:by("dialog-body"),children:[(0,d.jsxs)(_e.s,{direction:"row",alignItems:"flex-start",className:by("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"queryMode",className:by("field-title"),children:fh.queryMode.title}),(0,d.jsx)("div",{className:by("control-wrapper",{queryMode:!0}),children:(0,d.jsx)(my.xI,{name:"queryMode",control:n,render:({field:e})=>(0,d.jsx)(vy,{id:"queryMode",setting:e.value,onUpdateSetting:t=>{e.onChange(t),"query"!==t&&null===u?r("timeout",""):"query"===t&&r("timeout",null)},settingOptions:fh.queryMode.options})})})]}),c&&(0,d.jsxs)(_e.s,{direction:"row",alignItems:"flex-start",className:by("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"tracingLevel",className:by("field-title"),children:fh.tracingLevel.title}),(0,d.jsx)("div",{className:by("control-wrapper"),children:(0,d.jsx)(my.xI,{name:"tracingLevel",control:n,render:({field:e})=>(0,d.jsx)(vy,{id:"tracingLevel",setting:e.value,onUpdateSetting:e.onChange,settingOptions:fh.tracingLevel.options})})})]}),(0,d.jsxs)(_e.s,{direction:"row",alignItems:"flex-start",className:by("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"transactionMode",className:by("field-title"),children:fh.transactionMode.title}),(0,d.jsx)("div",{className:by("control-wrapper",{transactionMode:!0}),children:(0,d.jsx)(my.xI,{name:"transactionMode",control:n,render:({field:e})=>(0,d.jsx)(vy,{id:"transactionMode",setting:e.value,onUpdateSetting:e.onChange,settingOptions:fh.transactionMode.options})})})]}),(0,d.jsxs)(_e.s,{direction:"row",alignItems:"flex-start",className:by("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"statisticsMode",className:by("field-title"),children:fh.statisticsMode.title}),(0,d.jsx)(Uv.m,{className:by("statistics-mode-tooltip"),disabled:!l,openDelay:0,content:hh("tooltip_plan-to-svg-statistics"),children:(0,d.jsx)("div",{className:by("control-wrapper",{statisticsMode:!0}),children:(0,d.jsx)(my.xI,{name:"statisticsMode",control:n,render:({field:e})=>(0,d.jsx)(vy,{id:"statisticsMode",disabled:l,setting:e.value,onUpdateSetting:e.onChange,settingOptions:fh.statisticsMode.options})})})})]}),(0,d.jsxs)(_e.s,{direction:"row",alignItems:"flex-start",className:by("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"limitRows",className:by("field-title"),children:fh.limitRows.title}),(0,d.jsx)("div",{className:by("control-wrapper"),children:(0,d.jsx)(my.xI,{name:"limitRows",control:n,render:({field:e})=>{var t,a;return(0,d.jsx)(On.k,{id:"limitRows",type:"number",...e,value:null===(t=e.value)||void 0===t?void 0:t.toString(),className:by("limit-rows"),placeholder:"10000",validationState:o.limitRows?"invalid":void 0,errorMessage:null===(a=o.limitRows)||void 0===a?void 0:a.message,errorPlacement:"inside",endContent:(0,d.jsx)("span",{className:by("postfix"),children:hh("form.limit.rows")})})}})})]}),(0,d.jsx)(_e.s,{direction:"row",alignItems:"flex-start",className:by("dialog-row"),children:(0,d.jsx)(my.xI,{name:"timeout",control:n,render:({field:e})=>{var t;return(0,d.jsx)(fy,{id:"timeout",value:"string"===typeof e.value?void 0:e.value,onChange:e.onChange,onToggle:t=>e.onChange(t?"":null),validationState:o.timeout?"invalid":void 0,errorMessage:null===(t=o.timeout)||void 0===t?void 0:t.message,isDisabled:m!==Ve.ei.query})}})})]}),(0,d.jsx)(Fn.l.Footer,{textButtonApply:hh("button-done"),textButtonCancel:hh("button-cancel"),onClickButtonCancel:a,propsButtonApply:{type:"submit"},renderButtons:(e,t)=>(0,d.jsxs)("div",{className:by("buttons-container"),children:[(0,d.jsx)(dn.$,{href:"https://ydb.tech/docs",target:"_blank",view:"outlined",size:"l",children:hh("docs")}),(0,d.jsxs)("div",{className:by("main-buttons"),children:[t,e]})]})})]})}var Sy=a(52400);const wy=(0,a(99006)._)((async()=>({Editor:(await Promise.resolve().then(a.bind(a,6376))).default})),"Editor");var Ny=a(41614),Ey=a(67913);const Cy=JSON.parse('{"context_syntax-error":"Syntax error"}'),Py=(0,he.g4)("ydb-monaco",{en:Cy}),Iy=(0,uu.debounce)((function(){var e;const t=null===(e=window.ydbEditor)||void 0===e?void 0:e.getModel();if(!t)return void console.error("unable to retrieve model when highlighting errors");const a=(0,Ny.kh)(t.getValue()).errors;if(!a.length)return void _y();const n=a.map((e=>({message:Py("context_syntax-error"),source:e.message,severity:Ey.MarkerSeverity.Error,startLineNumber:e.startLine,startColumn:e.startColumn+1,endLineNumber:e.endLine,endColumn:e.endColumn+1})));Ey.editor.setModelMarkers(t,"ydb",n)}),500);function Dy(){const e=(t=Iy,n.useEffect((()=>()=>{t.cancel()}),[t]),t);var t;return n.useCallback((()=>{_y(),e()}),[e])}function _y(){Ey.editor.removeAllMarkers("ydb")}const Ay="navigation";function Ry({changeUserInput:e,theme:t,handleSendExecuteClick:a,handleGetExplainQueryClick:s}){const r=(0,b.N4)(So.Wp),i=(0,b.YQ)(),[o,l]=n.useState(),c=(0,b.N4)(So.py),[u]=(0,b.iK)(f.bz),m=function(){const[e]=(0,b.iK)(f.LK),[t]=(0,b.iK)(f.IO);return n.useMemo((()=>{const a=Boolean(e);return{quickSuggestions:a,suggestOnTriggerCharacters:a,acceptSuggestionOnEnter:t?"on":"off",...Mv}}),[e,t])}(),p=Dy(),[h]=(0,b.iK)(f.zk),v=(0,b.A5)((()=>c&&0!==c.length?c[c.length-1].queryText:"")),g=(0,b.A5)((()=>{h===Ve.x5.explain?s(r):a(r)})),{monacoGhostConfig:y,prepareUserQueriesCache:x}=function(){const[e]=Ov.useLazyGetCodeAssistSuggestionsQuery(),[t]=Ov.useAcceptSuggestionMutation(),[a]=Ov.useDiscardSuggestionMutation(),[s]=Ov.useIgnoreSuggestionMutation(),[r]=Ov.useSendUserQueriesDataMutation(),i=(0,b.N4)(So.py),o=Ro(),l=n.useCallback((async t=>e(t).unwrap()),[e]),c=n.useCallback((async e=>t(e).unwrap()),[t]),d=n.useCallback((async e=>a(e).unwrap()),[a]),u=n.useCallback((async e=>s(e).unwrap()),[s]),m=n.useMemo((()=>[...i.map(((e,t)=>({name:`query${t}.yql`,text:e.queryText}))),...o.map((e=>({name:e.name,text:e.body})))]),[i,o]);return{prepareUserQueriesCache:n.useCallback((async()=>{const e=m.map(((e,t)=>({FileName:e.name||`query${t}.yql`,Text:e.text})));try{return await r(e).unwrap()}catch{return{items:[]}}}),[r,m]),monacoGhostConfig:n.useMemo((()=>({api:{getCodeAssistSuggestions:l},eventHandlers:{onCompletionAccept:c,onCompletionDecline:d,onCompletionIgnore:u},config:{language:"yql"}})),[l,c,d,u])}}();n.useEffect((()=>(o&&u&&(o.register(y),x()),()=>{null===o||void 0===o||o.unregister()})),[u,y,o,x]);return(0,d.jsx)(wy,{language:"yql",value:r,options:m,onChange:t=>{p(),e({input:t}),i((0,So.Xb)(!0))},editorDidMount:(e,t)=>{window.ydbEditor=e;const n=function(e){const{KeyMod:t,KeyCode:a}=e,n=t.CtrlCmd;return{sendQuery:n|a.Enter,sendSelectedQuery:n|t.Shift|e.KeyCode.Enter,selectPreviousQuery:n|a.UpArrow,selectNextQuery:n|a.DownArrow,saveQuery:n|a.KeyS,saveSelectedQuery:n|t.Shift|a.KeyS,shortcutsHotkey:n|a.KeyK}}(t);t.editor.registerCommand("insertSnippetToEditor",((t,a)=>{const n=e.getContribution("snippetController2");n&&(e.focus(),e.setValue(""),n.insert(a),i((0,So.Xb)(!1)))})),window.api.codeAssist&&l((0,Sy._z)(e)),function(e){const t=F()((()=>{e.layout()}),100);e.layout(),window.addEventListener("resize",t),e.onDidDispose((()=>{window.removeEventListener("resize",t)}))}(e),function(e,t){ky(e.getValue(),t()),e.onDidChangeModelContent((()=>{ky(e.getValue(),t())})),e.onDidDispose((()=>{window.onbeforeunload=null}))}(e,v),e.focus(),e.addAction({id:"sendQuery",label:oh("action.send-query"),keybindings:[n.sendQuery],precondition:void 0,keybindingContext:void 0,contextMenuGroupId:Ay,contextMenuOrder:1,run:()=>g()});const s=e.createContextKey("canSendSelectedText",!1);e.onDidChangeCursorSelection((({selection:e,secondarySelections:t})=>{const a=e.selectionStartLineNumber!==e.positionLineNumber||e.selectionStartColumn!==e.positionColumn,n=t.length>0;s.set(a&&!n)})),e.addAction({id:"sendSelectedQuery",label:oh("action.send-selected-query"),keybindings:[n.sendSelectedQuery],precondition:"canSendSelectedText",contextMenuGroupId:Ay,contextMenuOrder:1,run:e=>{const t=e.getSelection(),n=e.getModel();if(t&&n){const e=n.getValueInRange({startLineNumber:t.getSelectionStart().lineNumber,startColumn:t.getSelectionStart().column,endLineNumber:t.getPosition().lineNumber,endColumn:t.getPosition().column});a(e,!0)}}}),e.addAction({id:"previous-query",label:oh("action.previous-query"),keybindings:[n.selectPreviousQuery],contextMenuGroupId:Ay,contextMenuOrder:2,run:()=>{i((0,So.JK)())}}),e.addAction({id:"next-query",label:oh("action.next-query"),keybindings:[n.selectNextQuery],contextMenuGroupId:Ay,contextMenuOrder:3,run:()=>{i((0,So.tS)())}}),e.addAction({id:"save-query",label:oh("action.save-query"),keybindings:[n.saveQuery],run:()=>{wo.Ay.show(Uo)}}),e.addAction({id:"openKeyboardShortcutsPanel",label:oh("action.open-shortcuts"),keybindings:[n.shortcutsHotkey],contextMenuGroupId:Ay,contextMenuOrder:4,run:()=>{const e=new CustomEvent("openKeyboardShortcutsPanel");window.dispatchEvent(e)}})},theme:`vs-${t}`,editorWillUnmount:()=>{window.ydbEditor=void 0}})}function ky(e,t){const a=!!e&&e!==t;window.onbeforeunload=a?e=>{e.preventDefault(),e.returnValue=""}:null}const Oy=(0,c.cn)("query-editor"),My={triggerExpand:!1,triggerCollapse:!1,collapsed:!0};function Ly(e){const t=(0,b.YQ)(),{tenantName:a,path:s,type:r,theme:i,changeUserInput:o,subType:l}=e,c=(0,b.N4)(So.yJ),u=(0,b.N4)(So.wf),m=(0,b.N4)(So.py),p=(0,b.N4)(So.Kz),v=(0,b.N4)(x.Ab),g=Boolean(u),[y]=(0,b.XS)(),j=(0,D.Oi)(),[T,S]=Th(),{resetBanner:w}=wh(),[N,E]=(0,b.iK)(f.zk),[C,P]=n.useState(""),[I]=(0,b.iK)(f.kO),_=(0,D.j2)()&&I&&y.queryMode===Ve.ei.query,[A]=So.JO.useUseSendQueryMutation(),[R]=So.JO.useUseStreamQueryMutation(),k=n.useMemo((()=>_?{displayIndices:{maxIndex:(y.limitRows||Ve.jU.limitRows)+1}}:void 0),[_,y.limitRows]);n.useEffect((()=>{c!==a&&t((0,So.Id)(a))}),[t,a,c]);const[O,M]=n.useReducer(Ih(f.GV),My);n.useEffect((()=>{M(Eh.triggerCollapse)}),[]),n.useEffect((()=>{M(v||g?Eh.triggerExpand:Eh.triggerCollapse)}),[v,g]);const L=(0,b.A5)(((e,n)=>{E(Ve.x5.execute),P(e),(0,uu.isEqual)(T,y)||(w(),S(y));const s=(0,dh.A)();if(_){const t=R({actionType:"execute",query:e,database:a,querySettings:y,enableTracingLevel:j});Lv.registerQuery(t)}else{const t=A({actionType:"execute",query:e,database:a,querySettings:y,enableTracingLevel:j,queryId:s});Lv.registerQuery(t)}var r;(t((0,x.o)(!1)),n)||(e!==(null===(r=m[p])||void 0===r?void 0:r.queryText)&&t((0,So.nO)({queryText:e,queryId:s})),t((0,So.Xb)(!1)));M(Eh.triggerExpand)})),q=()=>{t((0,Ao.NJ)("settings"))},z=(0,b.A5)((e=>{E(Ve.x5.explain),P(e),(0,uu.isEqual)(T,y)||(w(),S(y));const n=(0,dh.A)(),s=A({actionType:"explain",query:e,database:a,querySettings:y,enableTracingLevel:j,queryId:n});Lv.registerQuery(s),t((0,x.o)(!1)),M(Eh.triggerExpand)}));return(0,d.jsxs)("div",{className:Oy(),children:[(0,d.jsxs)(h,{direction:"vertical",defaultSizePaneKey:f.l_,triggerCollapse:O.triggerCollapse,triggerExpand:O.triggerExpand,minSize:[0,52],collapsedSizes:[100,0],onSplitStartDragAdditional:()=>{M(Eh.clear)},children:[(0,d.jsxs)("div",{className:Oy("pane-wrapper",{top:!0}),children:[(0,d.jsx)("div",{className:Oy("monaco-wrapper"),children:(0,d.jsx)("div",{className:Oy("monaco"),children:(0,d.jsx)(Ry,{changeUserInput:o,theme:i,handleSendExecuteClick:L,handleGetExplainQueryClick:z})})}),(0,d.jsx)(Vv,{handleSendExecuteClick:L,onSettingsButtonClick:q,isLoading:Boolean(null===u||void 0===u?void 0:u.isLoading),handleGetExplainQueryClick:z,highlightedAction:N,tenantName:a,queryId:null===u||void 0===u?void 0:u.queryId,isStreamingEnabled:_})]}),(0,d.jsx)("div",{className:Oy("pane-wrapper"),children:(0,d.jsx)(qy,{resultVisibilityState:O,onExpandResultHandler:()=>{M(Eh.triggerExpand)},onCollapseResultHandler:()=>{M(Eh.triggerCollapse)},type:r,subType:l,theme:i,result:u,tenantName:a,path:s,showPreview:v,queryText:C,tableSettings:k},null===u||void 0===u?void 0:u.queryId)})]}),(0,d.jsx)(jy,{})]})}function qy({resultVisibilityState:e,onExpandResultHandler:t,onCollapseResultHandler:a,type:n,subType:s,theme:r,result:i,tenantName:o,path:l,showPreview:c,queryText:u,tableSettings:m}){return c?(0,d.jsx)(Kh,{database:o,path:l,type:n,subType:s}):i?(0,d.jsx)(dy,{result:i,resultType:null===i||void 0===i?void 0:i.type,theme:r,tenantName:o,isResultsCollapsed:e.collapsed,tableSettings:m,onExpandResults:t,onCollapseResults:a,queryText:u}):null}const zy=[{id:S.tQ.newQuery,title:oh("tabs.newQuery")},{id:S.tQ.history,title:oh("tabs.history")},{id:S.tQ.saved,title:oh("tabs.saved")}],Fy=({className:e,activeTab:t})=>{const a=(0,zs.zy)(),n=(0,U.mA)(a);return(0,d.jsx)("div",{className:e,children:(0,d.jsx)(w.t,{size:"l",allowNotSelected:!0,activeTab:t,items:zy,wrapTo:({id:e},t)=>{const a=(0,Pa.YL)({...n,[Pa.vh.queryTab]:e});return(0,d.jsx)(xo.E,{to:a,children:t},e)}})})};var Uy=a(65872),Qy=a(64470);const $y=(0,c.cn)("ydb-saved-queries"),By=({visible:e,queryName:t,onCancelClick:a,onConfirmClick:n})=>(0,d.jsxs)(Fn.l,{open:e,hasCloseButton:!1,size:"s",onClose:a,onEnterKeyDown:n,children:[(0,d.jsx)(Fn.l.Header,{caption:oh("delete-dialog.header")}),(0,d.jsxs)(Fn.l.Body,{className:$y("dialog-body"),children:[oh("delete-dialog.question"),(0,d.jsx)("span",{className:$y("dialog-query-name"),children:` ${t}?`})]}),(0,d.jsx)(Fn.l.Footer,{textButtonApply:oh("delete-dialog.delete"),textButtonCancel:oh("delete-dialog.cancel"),onClickButtonCancel:a,onClickButtonApply:n})]}),Hy=({changeUserInput:e})=>{const t=Ro(),a=(0,b.YQ)(),s=(0,b.N4)(Ao.cu),[r,i]=n.useState(!1),[o,l]=n.useState(""),c=()=>{i(!1),l("")},u=Go(n.useCallback((({queryText:t,queryName:n})=>{e({input:t}),a((0,So.Xb)(!1)),a((0,Ao.JP)(n)),a((0,_.sH)(S.tQ.newQuery))}),[e,a])),m=[{name:"name",header:"Name",render:({row:e})=>(0,d.jsx)("div",{className:$y("query-name"),children:e.name}),width:200},{name:"body",header:"Query Text",render:({row:e})=>{return(0,d.jsxs)("div",{className:$y("query"),children:[(0,d.jsx)("div",{className:$y("query-body"),children:(0,d.jsx)(Jo,{value:e.body,maxQueryHeight:6})}),(0,d.jsxs)("span",{className:$y("controls"),children:[(0,d.jsx)(dn.$,{view:"flat-secondary",children:(0,d.jsx)(Re.I,{data:Uy.A})}),(0,d.jsx)(dn.$,{view:"flat-secondary",onClick:(t=e.name,e=>{e.stopPropagation(),i(!0),l(t)}),children:(0,d.jsx)(Re.I,{data:Qy.A})})]})]});var t},sortable:!1,resizeMinWidth:650}];return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)(de.L,{className:$y(),children:[(0,d.jsx)(de.L.Controls,{children:(0,d.jsx)(pe.v,{onChange:e=>{a((0,Ao.ys)(e))},placeholder:oh("filter.text.placeholder"),className:$y("search")})}),(0,d.jsx)(de.L.Table,{children:(0,d.jsx)(ce.l,{columnsWidthLSKey:"savedQueriesTableColumnsWidth",columns:m,data:t,settings:Xo,emptyDataMessage:oh(s?"history.empty-search":"saved.empty"),rowClassName:()=>$y("row"),onRowClick:e=>u({queryText:e.body,queryName:e.name}),initialSortOrder:{columnId:"name",order:Pt.Ay.ASCENDING}})})]}),(0,d.jsx)(By,{visible:r,queryName:o,onCancelClick:()=>{c()},onConfirmClick:()=>{c(),a((0,Ao.fu)(o)),l("")}})]})},Wy=(0,c.cn)("ydb-query"),Gy=e=>{const t=(0,b.YQ)(),{queryTab:a=S.tQ.newQuery}=(0,b.N4)((e=>e.tenant)),r=e=>{t((0,So.iZ)(e))},i=n.useMemo((()=>zy.find((({id:e})=>e===a))),[a]);return(0,d.jsxs)("div",{className:Wy(),children:[i?(0,d.jsx)(s.mg,{children:(0,d.jsx)("title",{children:i.title})}):null,(0,d.jsx)(Fy,{className:Wy("tabs"),activeTab:a}),(0,d.jsx)("div",{className:Wy("content"),children:(()=>{switch(a){case S.tQ.newQuery:return(0,d.jsx)(Ly,{changeUserInput:r,...e});case S.tQ.history:return(0,d.jsx)(ch,{changeUserInput:r});case S.tQ.saved:return(0,d.jsx)(Hy,{changeUserInput:r});default:return null}})()})]})};var Vy=a(46649),Jy=a(93844);const Ky=["query","diagnostics"],Yy={query:Vy.A,diagnostics:Jy.A};const Zy=(0,c.cn)("ydb-tenant-navigation"),Xy=({id:e,title:t,icon:a})=>({value:e,content:(0,d.jsxs)("span",{className:Zy("item"),children:[(0,d.jsx)(Re.I,{data:a,size:16,className:Zy("icon")}),(0,d.jsx)("span",{className:Zy("text"),children:t})]})}),ex=()=>{const e=function(){const e=(0,zs.W6)(),t=(0,zs.zy)(),a=(0,U.mA)(t),[,s]=(0,b.iK)(f.Mt),{tenantPage:r}=(0,b.N4)((e=>e.tenant)),i=n.useMemo((()=>{if(t.pathname!==U.Ay.tenant)return[];const n=Ky.map((t=>{const n=S.Dg[t],i=(0,Pa.YL)({...a,[S.Dt]:n});return{id:n,title:fr(`pages.${t}`),icon:Yy[t],path:i,current:r===n,onForward:()=>{s(n),e.push(i)}}}));return n}),[r,s,t.pathname,e,a]);return i}();return(0,d.jsx)("div",{className:Zy(),children:(0,d.jsx)(du.a,{width:"auto",onUpdate:t=>{const a=e.find((e=>e.id===t));null===a||void 0===a||a.onForward()},size:"l",className:Zy("body"),value:(e.find((e=>e.current))||e[0]).id,options:e.map(Xy)})})},tx=(0,c.cn)("object-general");const ax=function(e){const t=(0,T.i)(),{tenantPage:a}=(0,b.N4)((e=>e.tenant));return(0,d.jsxs)("div",{className:tx(),children:[(0,d.jsx)(ex,{}),(()=>{const{type:n,subType:s,additionalTenantProps:r,additionalNodesProps:i,tenantName:o,path:l}=e;return a===S.Dg.query?(0,d.jsx)(Gy,{tenantName:o,path:l,theme:t,type:n,subType:s}):(0,d.jsx)(rh,{type:n,subType:s,tenantName:o,path:l,additionalTenantProps:r,additionalNodesProps:i})})()]})};var nx=a(1956);const sx=g.F.injectEndpoints({endpoints:e=>({getSchemaAcl:e.query({queryFn:async({path:e,database:t},{signal:a})=>{try{const n=await window.api.viewer.getSchemaAcl({path:e,database:t},{signal:a});return{data:{acl:n.Common.ACL,effectiveAcl:n.Common.EffectiveACL,owner:n.Common.Owner,interruptInheritance:n.Common.InterruptInheritance}}}catch(n){return{error:n}}},providesTags:["SchemaTree"]})}),overrideExisting:"throw"}),rx=JSON.parse('{"title_rights":"Access Rights","title_effective-rights":"Effective Access Rights","title_owner":"Owner","title_interupt-inheritance":"Interrupt inheritance","description_empty":"No Acl data"}'),ix=(0,he.g4)("ydb-acl",{en:rx}),ox=(0,c.cn)("ydb-acl"),lx=["access","type","inheritance"],cx={access:"Access",type:"Access type",inheritance:"Inheritance type"},dx=new Set(["Object","Container"]);function ux({value:e}){const t="string"===typeof e?[e]:e;return(0,d.jsx)("div",{className:ox("definition-content"),children:t.map((e=>(0,d.jsx)("span",{children:e},e)))})}function mx(e){if(!e||!e.length)return[];const t=function(e){return e.map((e=>{const{AccessRules:t=[],AccessRights:a=[],AccessType:n,InheritanceType:s,Subject:r}=e,i=t.concat(a),o="Allow"===n?void 0:n;let l;return((null===s||void 0===s?void 0:s.length)!==dx.size||s.some((e=>!dx.has(e))))&&(l=s),{access:i.length?i:void 0,type:o,inheritance:l,Subject:r}}))}(e);return t.map((({Subject:e,...t})=>{const a=Object.entries(t).filter((([e,t])=>Boolean(t)));return 1===a.length&&"access"===a[0][0]?{name:e,content:(0,d.jsx)(ux,{value:a[0][1]}),multilineName:!0}:{label:(0,d.jsx)("span",{className:ox("group-label"),children:e}),items:lx.map((e=>{const a=t[e];if(a)return{name:cx[e],content:(0,d.jsx)(ux,{value:a}),multilineName:!0}})).filter(Nr.f8)}}))}const px=({path:e,database:t})=>{const{currentData:a,isFetching:s,error:r}=sx.useGetSchemaAclQuery({path:e,database:t}),i=s&&!a,{acl:o,effectiveAcl:l,owner:c,interruptInheritance:u}=a||{},m=mx(o),p=mx(l),h=function(e){const t=(a=e,a&&a.endsWith("@staff")&&!a.startsWith("svc_")?a.split("@")[0]:a);var a;return t?[{name:t,content:ix("title_owner"),multilineName:!0}]:[]}(c),v=u?[{name:ix("title_interupt-inheritance"),content:(0,d.jsx)(Re.I,{data:nx.A,size:20}),multilineName:!0}]:[];if(i)return(0,d.jsx)(O.a,{});if(r)return(0,d.jsx)(k.o,{error:r});if(!o&&!c&&!l)return(0,d.jsx)(n.Fragment,{children:ix("description_empty")});const g=h.concat(m);return(0,d.jsxs)("div",{className:ox(),children:[(0,d.jsx)(hx,{items:v}),(0,d.jsx)(hx,{items:g,title:ix("title_rights")}),(0,d.jsx)(hx,{items:p,title:ix("title_effective-rights")})]})};function hx({items:e,title:t}){return e.length?(0,d.jsxs)(n.Fragment,{children:[t&&(0,d.jsx)("div",{className:ox("list-title"),children:t}),(0,d.jsx)(Gs.u,{items:e,nameMaxWidth:200,className:ox("result",{"no-title":!t}),responsive:!0})]}):null}var vx=a(87285);const gx=(e,t,a)=>{const{setActivePath:n}=a;return{openPreview:()=>{t(g.F.util.invalidateTags(["PreviewData"])),t((0,x.o)(!0)),t((0,_.es)(S.Dg.query)),t((0,_.sH)(S.tQ.newQuery)),n(e)}}},yx=(e,t)=>(0,d.jsx)(dn.$,{view:"flat-secondary",onClick:e.openPreview,title:fr("actions.openPreview"),size:t||"s",children:(0,d.jsx)(Re.I,{data:vx.A})}),xx=(e,t,a,n)=>(s,r,i)=>{const o=gx(s,e,t),l=yx(o,a),c=(null===i||void 0===i?void 0:i.subType)===Ze.EPathSubTypeStreamImpl;return{async_replication:void 0,transfer:void 0,database:void 0,directory:void 0,resource_pool:void 0,table:l,column_table:l,index_table:void 0,topic:n&&!c?l:void 0,stream:void 0,index:void 0,external_table:l,external_data_source:void 0,view:l}[r]},fx=(e,t,a)=>(n,s)=>{const r=gx(n,e,t);return{preview:yx(r,a)}[s]};var bx=a(89974),jx=a(3228);const Tx=5*f.KF,Sx=g.F.injectEndpoints({endpoints:e=>({getTableSchemaData:e.query({queryFn:async({path:e,tenantName:t,type:a},{dispatch:n})=>{try{if(jt(a)){const a=await n(Ke.endpoints.getViewSchema.initiate({database:t,path:e,timeout:Tx}));if((0,Ve.We)(a))return{error:a};return{data:Yt(a.data)}}const s=await n(y.endpoints.getOverview.initiate({path:e,database:t,timeout:Tx}));return{data:Kt(a,s.data)}}catch(s){return{error:s}}}})})});var wx=a(51016),Nx=a(49917),Ex=a(32133),Cx=a.n(Ex);function Px(e,t){const a=e.replace(/^\/+|\/+$/g,""),n=t.replace(/^\/+|\/+$/g,"");if(!a.startsWith(n))return a||"/";if(a===n)return`/${a}`;let s=a.slice(n.length);return s=s.replace(/^\/+/,"")||"/",s}function Ix(e,t){return t===Ye.EPathTypeDir&&(2===e.split("/").length&&e.startsWith("/"))}const Dx=({text:e,action:t,isLoading:a})=>({text:(0,d.jsxs)(_e.s,{justifyContent:"space-between",alignItems:"center",children:[e,a&&(0,d.jsx)(Yv.t,{size:"xs"})]}),action:t,disabled:a}),_x=(e,t,a="")=>(n,s)=>{const r=((e,t,a)=>{const{setActivePath:n,showCreateDirectoryDialog:s,getConfirmation:r,getConnectToDBDialog:i,schemaData:o}=a,l=a=>()=>{const s=()=>{t((0,_.es)(S.Dg.query)),t((0,_.sH)(S.tQ.newQuery)),n(e.path),Xh(a({...e,schemaData:o}))};r?r().then((e=>{e&&s()})):s()};return{createDirectory:s?()=>{s(e.path)}:void 0,getConnectToDBDialog:()=>null===i||void 0===i?void 0:i({database:e.path}),createTable:l(tv),createColumnTable:l(av),createAsyncReplication:l(nv),alterAsyncReplication:l(xv),dropAsyncReplication:l(gv),createTransfer:l(sv),alterTransfer:l(fv),dropTransfer:l(yv),alterTable:l(rv),dropTable:l(_v),manageAutoPartitioning:l(iv),selectQuery:l(ov),upsertQuery:l(lv),createExternalTable:l(dv),dropExternalTable:l(cv),selectQueryFromExternalTable:l(ov),createTopic:l(uv),alterTopic:l(mv),dropTopic:l(pv),createView:l(hv),dropView:l(vv),dropIndex:l(jv),addTableIndex:l(bv),createCdcStream:l(Tv),copyPath:()=>{try{Cx()(e.relativePath),qe({name:"Copied",title:fr("actions.copied"),type:"success"})}catch{qe({name:"Not copied",title:fr("actions.notCopied"),type:"error"})}}}})({path:n,relativePath:Px(n,a),tenantName:a,type:s},e,t),i={text:fr("actions.copyPath"),action:r.copyPath,iconEnd:(0,d.jsx)(wx.A,{})},o={text:fr("actions.connectToDB"),action:r.getConnectToDBDialog,iconEnd:(0,d.jsx)(Nx.A,{})},l=[{text:fr("actions.createTable"),action:r.createTable},{text:fr("actions.createColumnTable"),action:r.createColumnTable},{text:fr("actions.createAsyncReplication"),action:r.createAsyncReplication},{text:fr("actions.createTransfer"),action:r.createTransfer},{text:fr("actions.createTopic"),action:r.createTopic},{text:fr("actions.createView"),action:r.createView}],c={text:fr("actions.alterTable"),items:[{text:fr("actions.manageColumns"),action:r.alterTable},{text:fr("actions.manageAutoPartitioning"),action:r.manageAutoPartitioning}]},u=[[i,o],l],m=[[i],l];if(r.createDirectory){const e={text:fr("actions.createDirectory"),action:r.createDirectory};u.splice(1,0,[e]),m.splice(1,0,[e])}const p=[[i],[c,{text:fr("actions.dropTable"),action:r.dropTable},Dx({text:fr("actions.selectQuery"),action:r.selectQuery,isLoading:t.isSchemaDataLoading}),Dx({text:fr("actions.upsertQuery"),action:r.upsertQuery,isLoading:t.isSchemaDataLoading}),{text:fr("actions.addTableIndex"),action:r.addTableIndex},{text:fr("actions.createCdcStream"),action:r.createCdcStream}]],h=[[i],[c,{text:fr("actions.dropTable"),action:r.dropTable},{text:fr("actions.selectQuery"),action:r.selectQuery},{text:fr("actions.upsertQuery"),action:r.upsertQuery}]],v=[[i],[{text:fr("actions.alterTopic"),action:r.alterTopic},{text:fr("actions.dropTopic"),action:r.dropTopic}]],g=[[i],[{text:fr("actions.selectQuery"),action:r.selectQueryFromExternalTable}],[{text:fr("actions.dropTable"),action:r.dropExternalTable}]],y=[[i],[{text:fr("actions.createExternalTable"),action:r.createExternalTable}]],x=[[i],[{text:fr("actions.selectQuery"),action:r.selectQuery}],[{text:fr("actions.dropView"),action:r.dropView}]],f=[i];return{async_replication:[[i],[{text:fr("actions.alterReplication"),action:r.alterAsyncReplication},{text:fr("actions.dropReplication"),action:r.dropAsyncReplication}]],transfer:[[i],[{text:fr("actions.alterTransfer"),action:r.alterTransfer},{text:fr("actions.dropTransfer"),action:r.dropTransfer}]],database:u,directory:m,resource_pool:f,table:p,column_table:h,index_table:f,topic:v,stream:f,index:[[i,{text:fr("actions.dropIndex"),action:r.dropIndex}]],external_table:g,external_data_source:y,view:x}[s]},Ax=(0,c.cn)("ydb-schema-create-directory-dialog"),Rx="relativePath";function kx({open:e,onClose:t,database:a,parentPath:s,onSuccess:r}){const[i,o]=n.useState(""),[l,c]=n.useState(""),[u,m]=x.sM.useCreateDirectoryMutation(),p=()=>{o(""),m.reset()},h=()=>{t(),c(""),p()};return(0,d.jsxs)(Fn.l,{open:e,onClose:h,size:"s",children:[(0,d.jsx)(Fn.l.Header,{caption:fr("schema.tree.dialog.header")}),(0,d.jsxs)("form",{onSubmit:e=>{e.preventDefault();const t=(n=l)?/\s/.test(n)?fr("schema.tree.dialog.whitespace"):"":fr("schema.tree.dialog.empty");var n;o(t),t||u({database:a,path:`${s}/${l}`}).unwrap().then((()=>{h(),r(l)}))},children:[(0,d.jsxs)(Fn.l.Body,{children:[(0,d.jsxs)("label",{htmlFor:Rx,className:Ax("label"),children:[(0,d.jsx)("span",{className:Ax("description"),children:fr("schema.tree.dialog.description")}),`${s}/`]}),(0,d.jsx)("div",{className:Ax("input-wrapper"),children:(0,d.jsx)(On.k,{placeholder:fr("schema.tree.dialog.placeholder"),value:l,onUpdate:e=>{c(e),p()},autoFocus:!0,hasClear:!0,autoComplete:!1,disabled:m.isLoading,validationState:i?"invalid":void 0,id:Rx,errorMessage:i})}),m.isError&&(0,d.jsx)(k.o,{error:m.error,defaultMessage:fr("schema.tree.dialog.invalid")})]}),(0,d.jsx)(Fn.l.Footer,{loading:m.isLoading,textButtonApply:fr("schema.tree.dialog.buttonApply"),textButtonCancel:fr("schema.tree.dialog.buttonCancel"),onClickButtonCancel:h,propsButtonApply:{type:"submit"}})]})]})}const Ox=n.createContext(void 0),Mx=n.createContext(void 0);function Lx({children:e}){const[t,a]=n.useState("");return(0,d.jsx)(Ox.Provider,{value:t,children:(0,d.jsx)(Mx.Provider,{value:a,children:e})})}function qx(){const e=n.useContext(Mx);if(void 0===e)throw new Error("useDispatchTreeKey must be used within a TreeKeyProvider");return e}function zx(e){const t=(0,D.Ii)(),{rootPath:a,rootName:s,rootType:r,currentPath:i,onActivePathUpdate:o}=e,l=(0,b.YQ)(),c=(0,b.N4)(So.Wp),u=(0,b.N4)(So.TY),[m,{currentData:p,isFetching:h}]=Sx.useLazyGetTableSchemaDataQuery(),v=(0,D._p)(),[g,y]=n.useState(!1),[f,j]=n.useState(""),T=qx(),S=function(){const e=n.useContext(Ox);if(void 0===e)throw new Error("useTreeKey must be used within a TreeKeyProvider");return e}(),w=Ix(a,r)?"database":st(r);n.useEffect((()=>{null!==i&&void 0!==i&&i.startsWith(a)||o(a)}),[i,o,a]);const N=e=>{j(e),y(!0)},E=n.useMemo((()=>_x(l,{setActivePath:o,showCreateDirectoryDialog:t?N:void 0,getConfirmation:c&&u?Wo:void 0,getConnectToDBDialog:jx.S,schemaData:p,isSchemaDataLoading:h},a)),[p,t,l,c,h,u,o,a]);return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(kx,{onClose:()=>{y(!1)},open:g,database:a,parentPath:f,onSuccess:e=>{const t=`${f}/${e}`;o(t),T(t)}}),(0,d.jsx)(bx.F,{rootState:{path:a,name:s,type:w,collapsed:!1},fetchPath:async e=>{let t;for(;;){const n=l(x.sM.endpoints.getSchema.initiate({path:e,database:a},{forceRefetch:!0})),{data:s,originalArgs:r}=await n;if(n.unsubscribe(),(null===r||void 0===r?void 0:r.path)===e){t=null===s||void 0===s?void 0:s[e];break}}if(!t)throw new Error(`no describe data about path ${e}`);const{PathDescription:{Children:n=[]}={}}=t;return n.map((e=>{const{Name:t="",PathType:a,PathSubType:n,ChildrenExist:s}=e,r=xt(a,n)||(0,Nr.f8)(s)&&!s;return{name:t,type:st(a,n),expandable:!r,meta:{subType:n}}}))},getActions:E,onActionsOpenToggle:({path:e,type:t,isOpen:n})=>{const s=nt[t];return n&&s&&m({path:e,tenantName:a,type:s}),[]},renderAdditionalNodeElements:xx(l,{setActivePath:o},void 0,v),activePath:i,onActivePathUpdate:o,cache:!1,virtualize:!0},S)]})}const Fx=JSON.parse('{"title_navigation":"Navigation","field_source-type":"Source Type","field_data-source":"Data Source","action_copySchemaPath":"Copy schema path","action_openInDiagnostics":"Open in Diagnostics","field_type":"Type","field_subtype":"SubType","field_id":"Id","field_version":"Version","field_created":"Created","field_data-size":"Data size","field_row-count":"Row count","field_partitions":"Partitions count","field_paths":"Paths","field_shards":"Shards","field_state":"State","field_mode":"Mode","field_format":"Format","field_retention":"Retention"}'),Ux=(0,he.g4)("ydb-object-summary",{en:Fx}),Qx=(0,c.cn)("ydb-object-summary");function $x({tenantName:e,path:t}){var a;const{data:n={},isLoading:s}=(0,x.Tn)({path:e,database:e}),i=null===n||void 0===n||null===(a=n.PathDescription)||void 0===a?void 0:a.Self,[,o]=(0,r.useQueryParam)("schema",r.StringParam);return!i&&s?(0,d.jsx)("div",{children:(0,d.jsx)(O.a,{})}):(0,d.jsxs)("div",{className:Qx("tree-wrapper"),children:[(0,d.jsx)("div",{className:Qx("tree-header"),children:Ux("title_navigation")}),(0,d.jsx)("div",{className:Qx("tree"),children:i?(0,d.jsx)(zx,{rootPath:e,rootName:(l=i.Name,c=e,l?l.startsWith("/")?l:`/${l}`:c.startsWith("/")?c:`/${c}`),rootType:i.PathType,currentPath:t,onActivePathUpdate:o}):null})]});var l,c}var Bx=a(16963);function Hx(){const e=(0,b.YQ)(),{diagnosticsTab:t,tenantPage:a}=(0,b.N4)((e=>e.tenant)),n=a===S.Dg.diagnostics&&t===S.iJ.schema;return(0,d.jsx)("div",{children:!n&&(0,d.jsx)(dn.$,{title:Ux("action_openInDiagnostics"),onClick:()=>{e((0,_.es)(S.Dg.diagnostics)),e((0,_.WO)(S.iJ.schema))},size:"s",children:(0,d.jsx)(Re.I,{data:Bx.A,size:14})})})}var Wx=a(8873),Gx=a(97091);function Vx(){const e=qx(),t=(0,b.YQ)();return(0,d.jsx)(Ae.m,{title:"Refresh",children:(0,d.jsx)(dn.$,{className:Qx("refresh-button"),view:"flat-secondary",onClick:()=>{e((0,Gx.Ak)()),t(g.F.util.invalidateTags(["SchemaTree"]))},children:(0,d.jsx)(Re.I,{data:Wx.A})})})}const Jx=()=>({triggerExpand:!1,triggerCollapse:!1,collapsed:Boolean(localStorage.getItem(f.hh))});function Kx({type:e,subType:t,tenantName:a,path:s,onCollapseSummary:i,onExpandSummary:o,isCollapsed:l}){var c;const u=(0,b.YQ)(),[,m]=(0,r.useQueryParam)("schema",r.StringParam),[p,v]=n.useReducer(Ih(f.hh),void 0,Jx),{summaryTab:g=S.ml.overview}=(0,b.N4)((e=>e.tenant)),x=(0,zs.zy)(),j=Ea().parse(x.search,{ignoreQueryPrefix:!0}),{currentData:T}=y.useGetOverviewQuery({path:s,database:a}),E=null===T||void 0===T||null===(c=T.PathDescription)||void 0===c?void 0:c.Self;n.useEffect((()=>{const t=ct(e);!e||t||Pa.x$.find((e=>e.id===g))||u((0,_.Mj)(S.ml.overview))}),[u,e,g]);const C=()=>{const t=ct(e)?[...Pa.x$,...Pa.nb]:Pa.x$;return(0,d.jsx)("div",{className:Qx("tabs"),children:(0,d.jsxs)(_e.s,{className:Qx("tabs-inner"),justifyContent:"space-between",alignItems:"center",children:[(0,d.jsx)(w.t,{size:"l",items:t,activeTab:g,wrapTo:({id:e},t)=>{const a=(0,Pa.YL)({...j,[Pa.vh.summaryTab]:e});return(0,d.jsx)(N.N_,{to:a,className:Qx("tab"),children:t},e)},allowNotSelected:!0}),g===S.ml.schema&&(0,d.jsx)(Hx,{})]})})},P=()=>{switch(g){case S.ml.acl:return(0,d.jsx)(px,{path:s,database:a});case S.ml.schema:return(0,d.jsx)(Zt,{type:e,path:s,tenantName:a});default:return(()=>{var e;if(!E)return;const{CreateStep:t,PathType:a,PathSubType:r,PathId:i,PathVersion:o}=E,l=[],c=Ix(s,a)?"Domain":null===a||void 0===a?void 0:a.replace(/^EPathType/,"");l.push({name:Ux("field_type"),content:c}),r!==Ze.EPathSubTypeEmpty&&l.push({name:Ux("field_subtype"),content:null===r||void 0===r?void 0:r.replace(/^EPathSubType/,"")}),l.push({name:Ux("field_id"),content:i}),l.push({name:Ux("field_version"),content:o}),Number(t)&&l.push({name:Ux("field_created"),content:(0,q.r6)(t)});const{PathDescription:u}=T;if(null!==u&&void 0!==u&&u.TableStats){const{DataSize:e,RowCount:t}=u.TableStats;l.push({name:Ux("field_data-size"),content:xs(e)},{name:Ux("field_row-count"),content:(0,q.ZV)(t)})}const m=()=>{var e;const{PathsInside:t,ShardsInside:a,PathsLimit:n,ShardsLimit:s}=null!==(e=null===u||void 0===u?void 0:u.DomainDescription)&&void 0!==e?e:{};let r=(0,q.ZV)(t),i=(0,q.ZV)(a);return r&&n&&(r=`${r} / ${(0,q.ZV)(n)}`),i&&s&&(i=`${i} / ${(0,q.ZV)(s)}`),[{name:Ux("field_paths"),content:r},{name:Ux("field_shards"),content:i}]},p={[Ye.EPathTypeInvalid]:void 0,[Ye.EPathTypeDir]:void 0,[Ye.EPathTypeResourcePool]:void 0,[Ye.EPathTypeTable]:()=>{var e;return[{name:Ux("field_partitions"),content:null===u||void 0===u||null===(e=u.TablePartitions)||void 0===e?void 0:e.length}]},[Ye.EPathTypeSubDomain]:m,[Ye.EPathTypeTableIndex]:void 0,[Ye.EPathTypeExtSubDomain]:m,[Ye.EPathTypeColumnStore]:()=>{var e,t;return[{name:Ux("field_partitions"),content:null===u||void 0===u||null===(e=u.ColumnStoreDescription)||void 0===e||null===(t=e.ColumnShards)||void 0===t?void 0:t.length}]},[Ye.EPathTypeColumnTable]:()=>{var e,t,a;return[{name:Ux("field_partitions"),content:null===u||void 0===u||null===(e=u.ColumnTableDescription)||void 0===e||null===(t=e.Sharding)||void 0===t||null===(a=t.ColumnShards)||void 0===a?void 0:a.length}]},[Ye.EPathTypeCdcStream]:()=>{const{Mode:e,Format:t}=(null===u||void 0===u?void 0:u.CdcStreamDescription)||{};return[{name:Ux("field_mode"),content:null===e||void 0===e?void 0:e.replace(/^ECdcStreamMode/,"")},{name:Ux("field_format"),content:null===t||void 0===t?void 0:t.replace(/^ECdcStreamFormat/,"")}]},[Ye.EPathTypePersQueueGroup]:()=>{var e,t,a;const n=null===u||void 0===u?void 0:u.PersQueueGroup,s=null===n||void 0===n||null===(e=n.PQTabletConfig)||void 0===e||null===(t=e.PartitionConfig)||void 0===t?void 0:t.LifetimeSeconds;return[{name:Ux("field_partitions"),content:null===n||void 0===n||null===(a=n.Partitions)||void 0===a?void 0:a.length},{name:Ux("field_retention"),content:s&&(0,q.Pt)(s)}]},[Ye.EPathTypeExternalTable]:()=>{var e,t;const a=(0,U.Ow)({...j,schema:null===u||void 0===u||null===(e=u.ExternalTableDescription)||void 0===e?void 0:e.DataSourcePath}),{SourceType:n,DataSourcePath:s}=(null===u||void 0===u?void 0:u.ExternalTableDescription)||{},r=(null===s||void 0===s||null===(t=s.match(/([^/]*)\/*$/))||void 0===t?void 0:t[1])||"";return[{name:Ux("field_source-type"),content:n},{name:Ux("field_data-source"),content:s&&(0,d.jsx)("span",{title:s,children:(0,d.jsx)(Fs.K,{title:r||"",url:a})})}]},[Ye.EPathTypeExternalDataSource]:()=>{var e;return[{name:Ux("field_source-type"),content:null===u||void 0===u||null===(e=u.ExternalDataSourceDescription)||void 0===e?void 0:e.SourceType}]},[Ye.EPathTypeView]:void 0,[Ye.EPathTypeReplication]:()=>{var e;const t=null===u||void 0===u||null===(e=u.ReplicationDescription)||void 0===e?void 0:e.State;return t?[{name:Ux("field_state"),content:(0,d.jsx)(Xs,{state:t})}]:[]},[Ye.EPathTypeTransfer]:()=>{var e;const t=null===u||void 0===u||null===(e=u.ReplicationDescription)||void 0===e?void 0:e.State;return t?[{name:Ux("field_state"),content:(0,d.jsx)(Xs,{state:t})}]:[]}},h=a&&(null===(e=p[a])||void 0===e?void 0:e.call(p))||[];l.push(...h);const v=l.filter((e=>e.content)).map((e=>({...e,content:(0,d.jsx)("div",{className:Qx("overview-item-content"),children:e.content})})));return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)("div",{className:Qx("overview-title"),children:(0,d.jsx)(br,{data:u})}),(0,d.jsx)(bp.u,{responsive:!0,children:v.map((e=>(0,d.jsx)(bp.u.Item,{name:e.name,children:e.content},e.name)))})]})})()}},I=()=>{v(Eh.triggerCollapse)},D=()=>{v(Eh.triggerExpand)},A=()=>{v(Eh.clear)},R=Px(s,a),k=()=>{const a=ct(e)&&!ut(t);return(0,d.jsxs)(n.Fragment,{children:[a&&fx(u,{setActivePath:m},"m")(s,"preview"),(0,d.jsx)(cn.b,{text:R,view:"flat-secondary",title:Ux("action_copySchemaPath")}),(0,d.jsx)(_h,{onCollapse:I,onExpand:D,isCollapsed:p.collapsed,initialDirection:"bottom"})]})},O=()=>{const{Status:t,Reason:a}=null!==T&&void 0!==T?T:{};if(e){let t=e.replace("EPathType","");return Ix(s,e)&&(t="domain"),(0,d.jsx)("div",{className:Qx("entity-type"),children:t})}let n;return t&&a&&(n=`${t}: ${a}`),(0,d.jsx)("div",{className:Qx("entity-type",{error:!0}),children:(0,d.jsx)(Ia.B,{content:n,offset:{left:0}})})};return(0,d.jsx)(Lx,{children:(0,d.jsxs)("div",{className:Qx(),children:[(0,d.jsx)("div",{className:Qx({hidden:l}),children:(0,d.jsxs)(h,{direction:"vertical",defaultSizePaneKey:f.ED,onSplitStartDragAdditional:A,triggerCollapse:p.triggerCollapse,triggerExpand:p.triggerExpand,minSize:[200,52],collapsedSizes:[100,0],children:[(0,d.jsx)($x,{tenantName:a,path:s}),(0,d.jsxs)("div",{className:Qx("info"),children:[(0,d.jsxs)("div",{className:Qx("sticky-top"),children:[(0,d.jsxs)("div",{className:Qx("info-header"),children:[(0,d.jsxs)("div",{className:Qx("info-title"),children:[O(),(0,d.jsx)("div",{className:Qx("path-name"),children:R})]}),(0,d.jsx)("div",{className:Qx("info-controls"),children:k()})]}),C()]}),(0,d.jsx)("div",{className:Qx("overview-wrapper"),children:P()})]})]})}),(0,d.jsxs)(_e.s,{className:Qx("actions"),gap:.5,children:[!l&&(0,d.jsx)(Vx,{}),(0,d.jsx)(_h,{onCollapse:i,onExpand:o,isCollapsed:l,initialDirection:"left"})]})]})})}const Yx=(0,c.cn)("tenant-page"),Zx=()=>({triggerExpand:!1,triggerCollapse:!1,collapsed:Boolean(localStorage.getItem(f.jX))});function Xx(e){var t,l,c,u,m,p,g,T,S,w;const[N,E]=n.useReducer(Ih(f.jX),void 0,Zx),[{database:C,name:P,schema:I},D]=(0,r.useQueryParams)({database:r.StringParam,name:r.StringParam,schema:r.StringParam});n.useEffect((()=>{P&&!C&&D({database:P,name:void 0},"replaceIn")}),[C,P,D]);const _=null!==C&&void 0!==C?C:P;if(!_)throw new Error("Tenant name is not defined");const A=n.useRef();n.useEffect((()=>{if(A.current!==_){(async()=>{const{registerYQLCompletionItemProvider:e}=await a.e(50245).then(a.bind(a,50245));e(_)})().catch(console.error),A.current=_}}),[_]);const R=(0,b.YQ)();n.useEffect((()=>{R((0,v.g)("tenant",{tenantName:_}))}),[_,R]);const k=null!==I&&void 0!==I?I:_,{currentData:O,error:M,isLoading:L}=y.useGetOverviewQuery({path:k,database:_}),q=(0,b.N4)((e=>(0,x.Tp)(e,k,_))),z=null!==(t=null===O||void 0===O||null===(l=O.PathDescription)||void 0===l||null===(c=l.Self)||void 0===c?void 0:c.PathType)&&void 0!==t?t:null===q||void 0===q||null===(u=q.PathDescription)||void 0===u||null===(m=u.Self)||void 0===m?void 0:m.PathType,F=null!==(p=null===O||void 0===O||null===(g=O.PathDescription)||void 0===g||null===(T=g.Self)||void 0===T?void 0:T.PathSubType)&&void 0!==p?p:null===q||void 0===q||null===(S=q.PathDescription)||void 0===S||null===(w=S.Self)||void 0===w?void 0:w.PathSubType,U=(0,j.Pq)(M),[Q,$]=n.useState(!0);Q&&!L&&$(!1);const B=k||fr("page.title");return(0,d.jsxs)("div",{className:Yx(),children:[(0,d.jsx)(s.mg,{defaultTitle:`${B} \u2014 YDB Monitoring`,titleTemplate:`%s \u2014 ${B} \u2014 YDB Monitoring`}),(0,d.jsx)(o.r,{loading:Q,children:(0,d.jsx)(i.A,{error:U?M:void 0,children:(0,d.jsxs)(h,{defaultSizePaneKey:f.jQ,defaultSizes:[25,75],triggerCollapse:N.triggerCollapse,triggerExpand:N.triggerExpand,minSize:[36,200],onSplitStartDragAdditional:()=>{E(Eh.clear)},children:[(0,d.jsx)(Kx,{type:z,subType:F,tenantName:_,path:k,onCollapseSummary:()=>{E(Eh.triggerCollapse)},onExpandSummary:()=>{E(Eh.triggerExpand)},isCollapsed:N.collapsed}),(0,d.jsx)("div",{className:Yx("main"),children:(0,d.jsx)(ax,{type:z,subType:F,additionalTenantProps:e.additionalTenantProps,additionalNodesProps:e.additionalNodesProps,tenantName:_,path:k})})]})})})]})}},52246:()=>{},52248:(e,t,a)=>{"use strict";a.d(t,{a:()=>n.a});var n=a(47334)},66574:()=>{},71635:(e,t,a)=>{"use strict";a.d(t,{C:()=>y});var n=a(44992),s=a(53850),r=a(62060),i=a.n(r),o=a(21334),l=a(24600);const c=o.F.injectEndpoints({endpoints:e=>({getTabletsInfo:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.viewer.getTabletsInfo(e,{signal:t})}}catch(a){return{error:a}}},providesTags:["All",{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"}),d=(0,s.Mz)((e=>e),(e=>c.endpoints.getTabletsInfo.select(e)),{argsMemoize:s.i5,argsMemoizeOptions:{equalityCheck:i()}}),u=(0,s.Mz)((e=>e),((e,t)=>d(t)),((e,t)=>t(e).data)),m=(0,s.Mz)(((e,t)=>u(e,t)),(e=>(0,l.K)(e)),((e,t)=>null!==e&&void 0!==e&&e.TabletStateInfo?t?e.TabletStateInfo.map((e=>{var a;const n=void 0===e.NodeId||null===(a=t.get(e.NodeId))||void 0===a?void 0:a.Host;return{...e,fqdn:n}})):e.TabletStateInfo:[]));var p=a(7435),h=a(90182),v=a(88616),g=a(60712);function y({nodeId:e,path:t,database:a,onlyActive:s,scrollContainerRef:r}){const[i]=(0,h.Nt)();let o={};const l=s?"(State!=Dead)":void 0;(0,p.f8)(e)?o={nodeId:e,database:a,filter:l}:t&&(o={path:t,database:a,filter:l});const{isLoading:d,error:u}=c.useGetTabletsInfoQuery(0===Object.keys(o).length?n.hT:o,{pollingInterval:i}),y=(0,h.N4)((e=>m(e,o)));return(0,g.jsx)(v.Q,{scrollContainerRef:r,tablets:y,database:a,loading:d,error:u})}},79737:(e,t,a)=>{"use strict";a.d(t,{A:()=>o,X:()=>l});var n=a(5874),s=a(77506),r=a(60712);const i=(0,s.cn)("ydb-table");function o({children:e,className:t}){return(0,r.jsx)("div",{className:i("table-header-content",t),children:e})}function l({className:e,width:t,wrapperClassName:a,...s}){return(0,r.jsx)("div",{className:i(null,a),children:(0,r.jsx)(n.W,{headerCellClassName:({column:e})=>{var t;const a=null===(t=e.columnDef.meta)||void 0===t?void 0:t.align;return i("table-header-cell",{align:a})},cellClassName:e=>{var t,a;const n=null===e||void 0===e||null===(t=e.column.columnDef.meta)||void 0===t?void 0:t.align,s=null===e||void 0===e||null===(a=e.column.columnDef.meta)||void 0===a?void 0:a.verticalAlign;return i("table-cell",{align:n,"vertical-align":s})},className:i("table",{width:t},e),...s})})}},94695:(e,t,a)=>{"use strict";a.r(t),a.d(t,{YDBSyntaxHighlighter:()=>f});var n=a(59284),s=a(96873),r=a(97091),i=a(96298);const o=(0,a(48372).g4)("ydb-syntax-highlighter",{en:{copy:"Copy"}});const l=(0,a(77506).cn)("ydb-syntax-highlighter");var c=a(22680),d=a(32138),u=a(62422);const m={...d.A,'pre[class*="language-"]':{...d.A['pre[class*="language-"]'],background:"transparent",margin:0},'code[class*="language-"]':{...d.A['code[class*="language-"]'],background:"transparent",color:"var(--g-color-text-primary)",whiteSpace:"pre-wrap"},comment:{color:"#969896"},string:{color:"#a31515"},tablepath:{color:"#338186"},function:{color:"#7a3e9d"},udf:{color:"#7a3e9d"},type:{color:"#4d932d"},boolean:{color:"#608b4e"},constant:{color:"#608b4e"},variable:{color:"#001188"}},p={...u.A,'pre[class*="language-"]':{...u.A['pre[class*="language-"]'],background:"transparent",margin:0},'code[class*="language-"]':{...u.A['code[class*="language-"]'],background:"transparent",color:"var(--g-color-text-primary)",whiteSpace:"pre-wrap"},comment:{color:"#969896"},string:{color:"#ce9178"},tablepath:{color:"#338186"},function:{color:"#9e7bb0"},udf:{color:"#9e7bb0"},type:{color:"#6A8759"},boolean:{color:"#608b4e"},constant:{color:"#608b4e"},variable:{color:"#74b0df"}},h={...p,'pre[class*="language-"]':{...p['pre[class*="language-"]'],background:u.A['pre[class*="language-"]'].background,scrollbarColor:"var(--g-color-scroll-handle) transparent"},'code[class*="language-"]':{...p['code[class*="language-"]'],whiteSpace:"pre"}},v={...m,'pre[class*="language-"]':{...m['pre[class*="language-"]'],background:"var(--g-color-base-misc-light)",scrollbarColor:"var(--g-color-scroll-handle) transparent"},'code[class*="language-"]':{...m['code[class*="language-"]'],whiteSpace:"pre"}};var g=a(43733);function y(e){e.languages.yql={comment:[{pattern:/--.*$/m,greedy:!0},{pattern:/\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0}],tablepath:{pattern:/(`[\w/]+`\s*\.\s*)?`[^`]+`/,greedy:!0},string:[{pattern:/'(?:\\[\s\S]|[^\\'])*'/,greedy:!0},{pattern:/"(?:\\[\s\S]|[^\\"])*"/,greedy:!0},{pattern:/@@(?:[^@]|@(?!@))*@@/,greedy:!0}],variable:[{pattern:/\$[a-zA-Z_]\w*/,greedy:!0}],function:{pattern:new RegExp(`\\b(?:${g.XB.join("|")})\\b`,"i"),greedy:!0},keyword:{pattern:new RegExp(`\\b(?:${g.RE.join("|")})\\b`,"i"),greedy:!0},udf:{pattern:/[A-Za-z_]\w*::[A-Za-z_]\w*/,greedy:!0},type:{pattern:new RegExp(`\\b(?:${g.to.join("|")})\\b`,"i"),greedy:!0},boolean:{pattern:/\b(?:true|false|null)\b/i,greedy:!0},number:{pattern:/[+-]?(?:\d+(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?/i,greedy:!0},operator:{pattern:/[-+*/%<>!=&|^~]+|\b(?:and|or|not|is|like|ilike|rlike|in|between)\b/i,greedy:!0},punctuation:{pattern:/[;[\](){}.,]/,greedy:!0}}}y.displayName="yql",y.aliases=["yql"];var x=a(60712);function f({text:e,language:t,className:d,transparentBackground:u=!0,withClipboardButton:g}){const[f,b]=n.useState(""),j=function(e){const t=(0,c.i)(),a="dark"===t||"dark-hc"===t;return e?a?p:m:a?h:v}(u);n.useEffect((()=>{!async function(){await async function(e){if("yql"===e)i.A.registerLanguage("yql",y);else{const{default:t}=await a(99648)(`./${e}`);i.A.registerLanguage(e,t)}}(t),b((0,r.Ak)())}()}),[t]);let T={};return g&&"object"===typeof g&&g.alwaysVisible&&(T=g.withLabel?{paddingRight:80}:{paddingRight:40}),(0,x.jsxs)("div",{className:l(null,d),children:[g?(0,x.jsx)("div",{className:l("sticky-container"),onClick:e=>e.stopPropagation(),children:(0,x.jsx)(s.b,{view:"flat-secondary",size:"s",className:l("copy",{visible:"object"===typeof g&&g.alwaysVisible}),text:"object"===typeof g&&g.copyText||e,children:"object"===typeof g&&!1===g.withLabel?null:o("copy")})}):null,(0,x.jsx)(i.A,{language:t,style:j,customStyle:{height:"100%",...T},children:e},f)]})}},99648:(e,t,a)=>{var n={"./":[84745,84745],"./abap":[67191,67191],"./abap.js":[67191,67191],"./abnf":[36754,36754],"./abnf.js":[36754,36754],"./actionscript":[69712,69712],"./actionscript.js":[69712,69712],"./ada":[87357,87357],"./ada.js":[87357,87357],"./agda":[61250,61250],"./agda.js":[61250,61250],"./al":[68220,68220],"./al.js":[68220,68220],"./antlr4":[73064,73064],"./antlr4.js":[73064,73064],"./apacheconf":[72401,72401],"./apacheconf.js":[72401,72401],"./apex":[94129,94129],"./apex.js":[94129,94129],"./apl":[98958,98958],"./apl.js":[98958,98958],"./applescript":[68990,68990],"./applescript.js":[68990,68990],"./aql":[84027,84027],"./aql.js":[84027,84027],"./arduino":[173,173],"./arduino.js":[173,173],"./arff":[82714,82714],"./arff.js":[82714,82714],"./asciidoc":[68818,68818],"./asciidoc.js":[68818,68818],"./asm6502":[1073,1073],"./asm6502.js":[1073,1073],"./asmatmel":[6197,6197],"./asmatmel.js":[6197,6197],"./aspnet":[55534,55534],"./aspnet.js":[55534,55534],"./autohotkey":[51400,51400],"./autohotkey.js":[51400,51400],"./autoit":[25007,25007],"./autoit.js":[25007,25007],"./avisynth":[80397,80397],"./avisynth.js":[80397,80397],"./avro-idl":[44391,44391],"./avro-idl.js":[44391,44391],"./bash":[80719,80719],"./bash.js":[80719,80719],"./basic":[51255,51255],"./basic.js":[51255,51255],"./batch":[85393,85393],"./batch.js":[85393,85393],"./bbcode":[78112,78112],"./bbcode.js":[78112,78112],"./bicep":[86814,86814],"./bicep.js":[86814,86814],"./birb":[66824,66824],"./birb.js":[66824,66824],"./bison":[11338,11338],"./bison.js":[11338,11338],"./bnf":[80555,80555],"./bnf.js":[80555,80555],"./brainfuck":[3534,3534],"./brainfuck.js":[3534,3534],"./brightscript":[9426,9426],"./brightscript.js":[9426,9426],"./bro":[91880,91880],"./bro.js":[91880,91880],"./bsl":[40388,40388],"./bsl.js":[40388,40388],"./c":[4664,4664],"./c.js":[4664,4664],"./cfscript":[79247,79247],"./cfscript.js":[79247,79247],"./chaiscript":[75523,75523],"./chaiscript.js":[75523,75523],"./cil":[99753,99753],"./cil.js":[99753,99753],"./clike":[31423,31423],"./clike.js":[31423,31423],"./clojure":[21989,21989],"./clojure.js":[21989,21989],"./cmake":[9930,9930],"./cmake.js":[9930,9930],"./cobol":[30226,30226],"./cobol.js":[30226,30226],"./coffeescript":[85622,85622],"./coffeescript.js":[85622,85622],"./concurnas":[30229,30229],"./concurnas.js":[30229,30229],"./coq":[25604,25604],"./coq.js":[25604,25604],"./core":[44846,44846],"./core.js":[44846,44846],"./cpp":[81571,81571],"./cpp.js":[81571,81571],"./crystal":[61747,61747],"./crystal.js":[61747,61747],"./csharp":[46306,46306],"./csharp.js":[46306,46306],"./cshtml":[17830,17830],"./cshtml.js":[17830,17830],"./csp":[23039,23039],"./csp.js":[23039,23039],"./css":[16242,16242],"./css-extras":[93696,93696],"./css-extras.js":[93696,93696],"./css.js":[16242,16242],"./csv":[7773,7773],"./csv.js":[7773,7773],"./cypher":[74394,74394],"./cypher.js":[74394,74394],"./d":[45517,45517],"./d.js":[45517,45517],"./dart":[79204,79204],"./dart.js":[79204,79204],"./dataweave":[62595,62595],"./dataweave.js":[62595,62595],"./dax":[31584,31584],"./dax.js":[31584,31584],"./dhall":[5254,5254],"./dhall.js":[5254,5254],"./diff":[73026,73026],"./diff.js":[73026,73026],"./django":[14382,14382],"./django.js":[14382,14382],"./dns-zone-file":[72188,72188],"./dns-zone-file.js":[72188,72188],"./docker":[6785,6785],"./docker.js":[6785,6785],"./dot":[59786,59786],"./dot.js":[59786,59786],"./ebnf":[55990,55990],"./ebnf.js":[55990,55990],"./editorconfig":[71266,71266],"./editorconfig.js":[71266,71266],"./eiffel":[93890,93890],"./eiffel.js":[93890,93890],"./ejs":[59605,59605],"./ejs.js":[59605,59605],"./elixir":[87138,87138],"./elixir.js":[87138,87138],"./elm":[88269,88269],"./elm.js":[88269,88269],"./erb":[69854,69854],"./erb.js":[69854,69854],"./erlang":[13470,13470],"./erlang.js":[13470,13470],"./etlua":[42912,42912],"./etlua.js":[42912,42912],"./excel-formula":[54861,54861],"./excel-formula.js":[54861,54861],"./factor":[16038,16038],"./factor.js":[16038,16038],"./false":[58666,58666],"./false.js":[58666,58666],"./firestore-security-rules":[66809,66809],"./firestore-security-rules.js":[66809,66809],"./flow":[80017,80017],"./flow.js":[80017,80017],"./fortran":[2251,2251],"./fortran.js":[2251,2251],"./fsharp":[85623,85623],"./fsharp.js":[85623,85623],"./ftl":[93691,93691],"./ftl.js":[93691,93691],"./gap":[35569,35569],"./gap.js":[35569,35569],"./gcode":[74729,74729],"./gcode.js":[74729,74729],"./gdscript":[91545,91545],"./gdscript.js":[91545,91545],"./gedcom":[69500,69500],"./gedcom.js":[69500,69500],"./gherkin":[15931,15931],"./gherkin.js":[15931,15931],"./git":[3061,3061],"./git.js":[3061,3061],"./glsl":[16097,16097],"./glsl.js":[16097,16097],"./gml":[72737,72737],"./gml.js":[72737,72737],"./gn":[2656,2656],"./gn.js":[2656,2656],"./go":[1431,1431],"./go-module":[88432,88432],"./go-module.js":[88432,88432],"./go.js":[1431,1431],"./graphql":[71588,71588],"./graphql.js":[71588,71588],"./groovy":[92551,92551],"./groovy.js":[92551,92551],"./haml":[4243,4243],"./haml.js":[4243,4243],"./handlebars":[22609,22609],"./handlebars.js":[22609,22609],"./haskell":[37677,37677],"./haskell.js":[37677,37677],"./haxe":[29193,29193],"./haxe.js":[29193,29193],"./hcl":[44866,44866],"./hcl.js":[44866,44866],"./hlsl":[24458,24458],"./hlsl.js":[24458,24458],"./hoon":[58457,58457],"./hoon.js":[58457,58457],"./hpkp":[3738,3738],"./hpkp.js":[3738,3738],"./hsts":[82505,82505],"./hsts.js":[82505,82505],"./http":[20053,20053],"./http.js":[20053,20053],"./ichigojam":[32670,32670],"./ichigojam.js":[32670,32670],"./icon":[92868,92868],"./icon.js":[92868,92868],"./icu-message-format":[88810,88810],"./icu-message-format.js":[88810,88810],"./idris":[93672,93672],"./idris.js":[93672,93672],"./iecst":[83005,83005],"./iecst.js":[83005,83005],"./ignore":[37747,37747],"./ignore.js":[37747,37747],"./index":[84745,84745],"./index.js":[84745,84745],"./inform7":[81327,81327],"./inform7.js":[81327,81327],"./ini":[61387,61387],"./ini.js":[61387,61387],"./io":[28125,28125],"./io.js":[28125,28125],"./j":[9511,9511],"./j.js":[9511,9511],"./java":[56421,56421],"./java.js":[56421,56421],"./javadoc":[85595,85595],"./javadoc.js":[85595,85595],"./javadoclike":[52036,52036],"./javadoclike.js":[52036,52036],"./javascript":[29866,29866],"./javascript.js":[29866,29866],"./javastacktrace":[83012,83012],"./javastacktrace.js":[83012,83012],"./jexl":[95264,95264],"./jexl.js":[95264,95264],"./jolie":[56026,56026],"./jolie.js":[56026,56026],"./jq":[62888,40507],"./jq.js":[62888,40507],"./js-extras":[84960,84960],"./js-extras.js":[84960,84960],"./js-templates":[79972,79972],"./js-templates.js":[79972,79972],"./jsdoc":[10242,10242],"./jsdoc.js":[10242,10242],"./json":[82315,82315],"./json.js":[82315,82315],"./json5":[57320,57320],"./json5.js":[57320,57320],"./jsonp":[88987,88987],"./jsonp.js":[88987,88987],"./jsstacktrace":[91087,91087],"./jsstacktrace.js":[91087,91087],"./jsx":[10064,10064],"./jsx.js":[10064,10064],"./julia":[6528,6528],"./julia.js":[6528,6528],"./keepalived":[29043,29043],"./keepalived.js":[29043,29043],"./keyman":[85776,85776],"./keyman.js":[85776,85776],"./kotlin":[85664,85664],"./kotlin.js":[85664,85664],"./kumir":[29461,29461],"./kumir.js":[29461,29461],"./kusto":[4617,4617],"./kusto.js":[4617,4617],"./latex":[30573,30573],"./latex.js":[30573,30573],"./latte":[84307,84307],"./latte.js":[84307,84307],"./less":[17880,17880],"./less.js":[17880,17880],"./lilypond":[23882,23882],"./lilypond.js":[23882,23882],"./liquid":[50045,50045],"./liquid.js":[50045,50045],"./lisp":[81869,81869],"./lisp.js":[81869,81869],"./livescript":[90504,90504],"./livescript.js":[90504,90504],"./llvm":[47472,47472],"./llvm.js":[47472,47472],"./log":[68527,68527],"./log.js":[68527,68527],"./lolcode":[98559,98559],"./lolcode.js":[98559,98559],"./lua":[71515,71515],"./lua.js":[71515,71515],"./magma":[33436,33436],"./magma.js":[33436,33436],"./makefile":[9177,9177],"./makefile.js":[9177,9177],"./markdown":[43028,43028],"./markdown.js":[43028,43028],"./markup":[66593,66593],"./markup-templating":[73863,73863],"./markup-templating.js":[73863,73863],"./markup.js":[66593,66593],"./matlab":[72020,72020],"./matlab.js":[72020,72020],"./maxscript":[42396,42396],"./maxscript.js":[42396,42396],"./mel":[16795,16795],"./mel.js":[16795,16795],"./mermaid":[35958,35958],"./mermaid.js":[35958,35958],"./mizar":[73442,73442],"./mizar.js":[73442,73442],"./mongodb":[5411,5411],"./mongodb.js":[5411,5411],"./monkey":[49788,49788],"./monkey.js":[49788,49788],"./moonscript":[4887,4887],"./moonscript.js":[4887,4887],"./n1ql":[25101,25101],"./n1ql.js":[25101,25101],"./n4js":[57708,57708],"./n4js.js":[57708,57708],"./nand2tetris-hdl":[78710,78710],"./nand2tetris-hdl.js":[78710,78710],"./naniscript":[70190,70190],"./naniscript.js":[70190,70190],"./nasm":[92008,92008],"./nasm.js":[92008,92008],"./neon":[90529,90529],"./neon.js":[90529,90529],"./nevod":[93771,93771],"./nevod.js":[93771,93771],"./nginx":[68377,68377],"./nginx.js":[68377,68377],"./nim":[31177,31177],"./nim.js":[31177,31177],"./nix":[16758,16758],"./nix.js":[16758,16758],"./nsis":[19702,19702],"./nsis.js":[19702,19702],"./objectivec":[34693,34693],"./objectivec.js":[34693,34693],"./ocaml":[89033,89033],"./ocaml.js":[89033,89033],"./opencl":[38718,38718],"./opencl.js":[38718,38718],"./openqasm":[76603,76603],"./openqasm.js":[76603,76603],"./oz":[72788,72788],"./oz.js":[72788,72788],"./parigp":[92816,92816],"./parigp.js":[92816,92816],"./parser":[63782,63782],"./parser.js":[63782,63782],"./pascal":[39705,39705],"./pascal.js":[39705,39705],"./pascaligo":[20600,20600],"./pascaligo.js":[20600,20600],"./pcaxis":[54597,54597],"./pcaxis.js":[54597,54597],"./peoplecode":[42791,42791],"./peoplecode.js":[42791,42791],"./perl":[34156,34156],"./perl.js":[34156,34156],"./php":[30249,30249],"./php-extras":[9493,9493],"./php-extras.js":[9493,9493],"./php.js":[30249,30249],"./phpdoc":[26327,26327],"./phpdoc.js":[26327,26327],"./plsql":[52541,52541],"./plsql.js":[52541,52541],"./powerquery":[90330,90330],"./powerquery.js":[90330,90330],"./powershell":[17500,17500],"./powershell.js":[17500,17500],"./processing":[5530,5530],"./processing.js":[5530,5530],"./prolog":[63025,85406],"./prolog.js":[63025,85406],"./promql":[1146,1146],"./promql.js":[1146,1146],"./properties":[47108,47108],"./properties.js":[47108,47108],"./protobuf":[81014,81014],"./protobuf.js":[81014,81014],"./psl":[96410,96410],"./psl.js":[96410,96410],"./pug":[54781,54781],"./pug.js":[54781,54781],"./puppet":[51159,51159],"./puppet.js":[51159,51159],"./pure":[26411,26411],"./pure.js":[26411,26411],"./purebasic":[57469,57469],"./purebasic.js":[57469,57469],"./purescript":[10132,10132],"./purescript.js":[10132,10132],"./python":[81243,81243],"./python.js":[81243,81243],"./q":[4018,4018],"./q.js":[4018,4018],"./qml":[19791,19791],"./qml.js":[19791,19791],"./qore":[81940,81940],"./qore.js":[81940,81940],"./qsharp":[60464,60464],"./qsharp.js":[60464,60464],"./r":[10815,10815],"./r.js":[10815,10815],"./racket":[90367,90367],"./racket.js":[90367,90367],"./reason":[65633,65633],"./reason.js":[65633,65633],"./regex":[56054,56054],"./regex.js":[56054,56054],"./rego":[94102,94102],"./rego.js":[94102,94102],"./renpy":[42111,42111],"./renpy.js":[42111,42111],"./rest":[34119,34119],"./rest.js":[34119,34119],"./rip":[70858,70858],"./rip.js":[70858,70858],"./roboconf":[54651,54651],"./roboconf.js":[54651,54651],"./robotframework":[10525,10525],"./robotframework.js":[10525,10525],"./ruby":[17981,17981],"./ruby.js":[17981,17981],"./rust":[8215,8215],"./rust.js":[8215,8215],"./sas":[21996,21996],"./sas.js":[21996,21996],"./sass":[71107,71107],"./sass.js":[71107,71107],"./scala":[30499,30499],"./scala.js":[30499,30499],"./scheme":[4554,4554],"./scheme.js":[4554,4554],"./scss":[96017,96017],"./scss.js":[96017,96017],"./shell-session":[56174,56174],"./shell-session.js":[56174,56174],"./smali":[3149,3149],"./smali.js":[3149,3149],"./smalltalk":[86472,86472],"./smalltalk.js":[86472,86472],"./smarty":[87429,87429],"./smarty.js":[87429,87429],"./sml":[37605,37605],"./sml.js":[37605,37605],"./solidity":[54520,54520],"./solidity.js":[54520,54520],"./solution-file":[61741,61741],"./solution-file.js":[61741,61741],"./soy":[47660,47660],"./soy.js":[47660,47660],"./sparql":[57016,57016],"./sparql.js":[57016,57016],"./splunk-spl":[19026,19026],"./splunk-spl.js":[19026,19026],"./sqf":[20535,20535],"./sqf.js":[20535,20535],"./sql":[87233,87233],"./sql.js":[87233,87233],"./squirrel":[65206,65206],"./squirrel.js":[65206,65206],"./stan":[29769,29769],"./stan.js":[29769,29769],"./stylus":[55651,55651],"./stylus.js":[55651,55651],"./supported-languages":[70289,70289],"./supported-languages.js":[70289,70289],"./swift":[46134,46134],"./swift.js":[46134,46134],"./systemd":[9614,9614],"./systemd.js":[9614,9614],"./t4-cs":[71672,71672],"./t4-cs.js":[71672,71672],"./t4-templating":[84587,84587],"./t4-templating.js":[84587,84587],"./t4-vb":[5282,5282],"./t4-vb.js":[5282,5282],"./tap":[83896,83896],"./tap.js":[83896,83896],"./tcl":[27950,27950],"./tcl.js":[27950,27950],"./textile":[42384,42384],"./textile.js":[42384,42384],"./toml":[37385,37385],"./toml.js":[37385,37385],"./tremor":[55528,55528],"./tremor.js":[55528,55528],"./tsx":[30850,30850],"./tsx.js":[30850,30850],"./tt2":[82399,82399],"./tt2.js":[82399,82399],"./turtle":[70695,70695],"./turtle.js":[70695,70695],"./twig":[98268,98268],"./twig.js":[98268,98268],"./typescript":[82066,82066],"./typescript.js":[82066,82066],"./typoscript":[3980,3980],"./typoscript.js":[3980,3980],"./unrealscript":[47153,47153],"./unrealscript.js":[47153,47153],"./uorazor":[56761,56761],"./uorazor.js":[56761,56761],"./uri":[83075,83075],"./uri.js":[83075,83075],"./v":[50875,50875],"./v.js":[50875,50875],"./vala":[42615,42615],"./vala.js":[42615,42615],"./vbnet":[21742,21742],"./vbnet.js":[21742,21742],"./velocity":[48914,48914],"./velocity.js":[48914,48914],"./verilog":[37963,37963],"./verilog.js":[37963,37963],"./vhdl":[80067,80067],"./vhdl.js":[80067,80067],"./vim":[67105,67105],"./vim.js":[67105,67105],"./visual-basic":[94810,94810],"./visual-basic.js":[94810,94810],"./warpscript":[11192,11192],"./warpscript.js":[11192,11192],"./wasm":[99341,99341],"./wasm.js":[99341,99341],"./web-idl":[5393,5393],"./web-idl.js":[5393,5393],"./wiki":[91249,91249],"./wiki.js":[91249,91249],"./wolfram":[19233,19233],"./wolfram.js":[19233,19233],"./wren":[89015,89015],"./wren.js":[89015,89015],"./xeora":[97440,97440],"./xeora.js":[97440,97440],"./xml-doc":[52527,52527],"./xml-doc.js":[52527,52527],"./xojo":[35803,35803],"./xojo.js":[35803,35803],"./xquery":[69997,69997],"./xquery.js":[69997,69997],"./yaml":[84578,84578],"./yaml.js":[84578,84578],"./yang":[35596,35596],"./yang.js":[35596,35596],"./zig":[43979,43979],"./zig.js":[43979,43979]};function s(e){if(!a.o(n,e))return Promise.resolve().then((()=>{var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}));var t=n[e],s=t[0];return a.e(t[1]).then((()=>a(s)))}s.keys=()=>Object.keys(n),s.id=99648,e.exports=s}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/29043.f0a51584.chunk.js b/ydb/core/viewer/monitoring/static/js/29043.f0a51584.chunk.js new file mode 100644 index 000000000000..46de25214da9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/29043.f0a51584.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[29043],{29043:(e,r,_)=>{_.d(r,{default:()=>i});var t=_(78150);const i=_.n(t)()},78150:e=>{function r(e){e.languages.keepalived={comment:{pattern:/[#!].*/,greedy:!0},string:{pattern:/(^|[^\\])(?:"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"|'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n])*')/,lookbehind:!0,greedy:!0},ip:{pattern:RegExp(/\b(?:(?:(?:[\da-f]{1,4}:){7}[\da-f]{1,4}|(?:[\da-f]{1,4}:){6}:[\da-f]{1,4}|(?:[\da-f]{1,4}:){5}:(?:[\da-f]{1,4}:)?[\da-f]{1,4}|(?:[\da-f]{1,4}:){4}:(?:[\da-f]{1,4}:){0,2}[\da-f]{1,4}|(?:[\da-f]{1,4}:){3}:(?:[\da-f]{1,4}:){0,3}[\da-f]{1,4}|(?:[\da-f]{1,4}:){2}:(?:[\da-f]{1,4}:){0,4}[\da-f]{1,4}|(?:[\da-f]{1,4}:){6}|(?:[\da-f]{1,4}:){0,5}:|::(?:[\da-f]{1,4}:){0,5}|[\da-f]{1,4}::(?:[\da-f]{1,4}:){0,5}[\da-f]{1,4}|::(?:[\da-f]{1,4}:){0,6}[\da-f]{1,4}|(?:[\da-f]{1,4}:){1,7}:)(?:\/\d{1,3})?|(?:\/\d{1,2})?)\b/.source.replace(//g,(function(){return/(?:(?:(?:25[0-5]|2[0-4]\d|1\d\d|[1-9]\d|\d)\.){3}(?:25[0-5]|2[0-4]\d|1\d\d|[1-9]\d|\d))/.source})),"i"),alias:"number"},path:{pattern:/(\s)\/(?:[^\/\s]+\/)*[^\/\s]*|\b[a-zA-Z]:\\(?:[^\\\s]+\\)*[^\\\s]*/,lookbehind:!0,alias:"string"},variable:/\$\{?\w+\}?/,email:{pattern:/[\w-]+@[\w-]+(?:\.[\w-]{2,3}){1,2}/,alias:"string"},"conditional-configuration":{pattern:/@\^?[\w-]+/,alias:"variable"},operator:/=/,property:/\b(?:BFD_CHECK|DNS_CHECK|FILE_CHECK|HTTP_GET|MISC_CHECK|NAME|PING_CHECK|SCRIPTS|SMTP_CHECK|SSL|SSL_GET|TCP_CHECK|UDP_CHECK|accept|advert_int|alpha|auth_pass|auth_type|authentication|bfd_cpu_affinity|bfd_instance|bfd_no_swap|bfd_priority|bfd_process_name|bfd_rlimit_rttime|bfd_rt_priority|bind_if|bind_port|bindto|ca|certificate|check_unicast_src|checker|checker_cpu_affinity|checker_log_all_failures|checker_no_swap|checker_priority|checker_rlimit_rttime|checker_rt_priority|child_wait_time|connect_ip|connect_port|connect_timeout|dbus_service_name|debug|default_interface|delay|delay_before_retry|delay_loop|digest|dont_track_primary|dynamic|dynamic_interfaces|enable_(?:dbus|script_security|sni|snmp_checker|snmp_rfc|snmp_rfcv2|snmp_rfcv3|snmp_vrrp|traps)|end|fall|fast_recovery|file|flag-[123]|fork_delay|full_command|fwmark|garp_group|garp_interval|garp_lower_prio_delay|garp_lower_prio_repeat|garp_master_delay|garp_master_refresh|garp_master_refresh_repeat|garp_master_repeat|global_defs|global_tracking|gna_interval|group|ha_suspend|hashed|helo_name|higher_prio_send_advert|hoplimit|http_protocol|hysteresis|idle_tx|include|inhibit_on_failure|init_fail|init_file|instance|interface|interfaces|interval|ip_family|ipvs_process_name|keepalived.conf|kernel_rx_buf_size|key|linkbeat_interfaces|linkbeat_use_polling|log_all_failures|log_unknown_vrids|lower_prio_no_advert|lthreshold|lvs_flush|lvs_flush_onstop|lvs_method|lvs_netlink_cmd_rcv_bufs|lvs_netlink_cmd_rcv_bufs_force|lvs_netlink_monitor_rcv_bufs|lvs_netlink_monitor_rcv_bufs_force|lvs_notify_fifo|lvs_notify_fifo_script|lvs_sched|lvs_sync_daemon|max_auto_priority|max_hops|mcast_src_ip|mh-fallback|mh-port|min_auto_priority_delay|min_rx|min_tx|misc_dynamic|misc_path|misc_timeout|multiplier|name|namespace_with_ipsets|native_ipv6|neighbor_ip|net_namespace|net_namespace_ipvs|nftables|nftables_counters|nftables_ifindex|nftables_priority|no_accept|no_checker_emails|no_email_faults|nopreempt|notification_email|notification_email_from|notify|notify_backup|notify_deleted|notify_down|notify_fault|notify_fifo|notify_fifo_script|notify_master|notify_master_rx_lower_pri|notify_priority_changes|notify_stop|notify_up|old_unicast_checksum|omega|ops|param_match|passive|password|path|persistence_engine|persistence_granularity|persistence_timeout|preempt|preempt_delay|priority|process|process_monitor_rcv_bufs|process_monitor_rcv_bufs_force|process_name|process_names|promote_secondaries|protocol|proxy_arp|proxy_arp_pvlan|quorum|quorum_down|quorum_max|quorum_up|random_seed|real_server|regex|regex_max_offset|regex_min_offset|regex_no_match|regex_options|regex_stack|reload_repeat|reload_time_file|require_reply|retry|rise|router_id|rs_init_notifies|script|script_user|sh-fallback|sh-port|shutdown_script|shutdown_script_timeout|skip_check_adv_addr|smtp_alert|smtp_alert_checker|smtp_alert_vrrp|smtp_connect_timeout|smtp_helo_name|smtp_server|snmp_socket|sorry_server|sorry_server_inhibit|sorry_server_lvs_method|source_ip|start|startup_script|startup_script_timeout|state|static_ipaddress|static_routes|static_rules|status_code|step|strict_mode|sync_group_tracking_weight|terminate_delay|timeout|track_bfd|track_file|track_group|track_interface|track_process|track_script|track_src_ip|ttl|type|umask|unicast_peer|unicast_src_ip|unicast_ttl|url|use_ipvlan|use_pid_dir|use_vmac|user|uthreshold|val[123]|version|virtual_ipaddress|virtual_ipaddress_excluded|virtual_router_id|virtual_routes|virtual_rules|virtual_server|virtual_server_group|virtualhost|vmac_xmit_base|vrrp|vrrp_(?:check_unicast_src|cpu_affinity|garp_interval|garp_lower_prio_delay|garp_lower_prio_repeat|garp_master_delay|garp_master_refresh|garp_master_refresh_repeat|garp_master_repeat|gna_interval|higher_prio_send_advert|instance|ipsets|iptables|lower_prio_no_advert|mcast_group4|mcast_group6|min_garp|netlink_cmd_rcv_bufs|netlink_cmd_rcv_bufs_force|netlink_monitor_rcv_bufs|netlink_monitor_rcv_bufs_force|no_swap|notify_fifo|notify_fifo_script|notify_priority_changes|priority|process_name|rlimit_rttime|rt_priority|rx_bufs_multiplier|rx_bufs_policy|script|skip_check_adv_addr|startup_delay|strict|sync_group|track_process|version)|warmup|weight)\b/,constant:/\b(?:A|AAAA|AH|BACKUP|CNAME|DR|MASTER|MX|NAT|NS|PASS|SCTP|SOA|TCP|TUN|TXT|UDP|dh|fo|lblc|lblcr|lc|mh|nq|ovf|rr|sed|sh|wlc|wrr)\b/,number:{pattern:/(^|[^\w.-])-?\d+(?:\.\d+)?/,lookbehind:!0},boolean:/\b(?:false|no|off|on|true|yes)\b/,punctuation:/[\{\}]/}}e.exports=r,r.displayName="keepalived",r.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/29193.43e37031.chunk.js b/ydb/core/viewer/monitoring/static/js/29193.43e37031.chunk.js new file mode 100644 index 000000000000..3a393bdec945 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/29193.43e37031.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[29193],{29193:(e,a,t)=>{t.d(a,{default:()=>r});var n=t(77332);const r=t.n(n)()},77332:e=>{function a(e){e.languages.haxe=e.languages.extend("clike",{string:{pattern:/"(?:[^"\\]|\\[\s\S])*"/,greedy:!0},"class-name":[{pattern:/(\b(?:abstract|class|enum|extends|implements|interface|new|typedef)\s+)[A-Z_]\w*/,lookbehind:!0},/\b[A-Z]\w*/],keyword:/\bthis\b|\b(?:abstract|as|break|case|cast|catch|class|continue|default|do|dynamic|else|enum|extends|extern|final|for|from|function|if|implements|import|in|inline|interface|macro|new|null|operator|overload|override|package|private|public|return|static|super|switch|throw|to|try|typedef|untyped|using|var|while)(?!\.)\b/,function:{pattern:/\b[a-z_]\w*(?=\s*(?:<[^<>]*>\s*)?\()/i,greedy:!0},operator:/\.{3}|\+\+|--|&&|\|\||->|=>|(?:<{1,3}|[-+*/%!=&|^])=?|[?:~]/}),e.languages.insertBefore("haxe","string",{"string-interpolation":{pattern:/'(?:[^'\\]|\\[\s\S])*'/,greedy:!0,inside:{interpolation:{pattern:/(^|[^\\])\$(?:\w+|\{[^{}]+\})/,lookbehind:!0,inside:{"interpolation-punctuation":{pattern:/^\$\{?|\}$/,alias:"punctuation"},expression:{pattern:/[\s\S]+/,inside:e.languages.haxe}}},string:/[\s\S]+/}}}),e.languages.insertBefore("haxe","class-name",{regex:{pattern:/~\/(?:[^\/\\\r\n]|\\.)+\/[a-z]*/,greedy:!0,inside:{"regex-flags":/\b[a-z]+$/,"regex-source":{pattern:/^(~\/)[\s\S]+(?=\/$)/,lookbehind:!0,alias:"language-regex",inside:e.languages.regex},"regex-delimiter":/^~\/|\/$/}}}),e.languages.insertBefore("haxe","keyword",{preprocessor:{pattern:/#(?:else|elseif|end|if)\b.*/,alias:"property"},metadata:{pattern:/@:?[\w.]+/,alias:"symbol"},reification:{pattern:/\$(?:\w+|(?=\{))/,alias:"important"}})}e.exports=a,a.displayName="haxe",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/29394.e027e9c7.chunk.js b/ydb/core/viewer/monitoring/static/js/29394.e027e9c7.chunk.js new file mode 100644 index 000000000000..3260c527998e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/29394.e027e9c7.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 29394.e027e9c7.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[29394],{29394:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>o,language:()=>a});var o={comments:{lineComment:"//"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]}],folding:{offSide:!0}},a={defaultToken:"",tokenPostfix:".pug",ignoreCase:!0,brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.array",open:"[",close:"]"},{token:"delimiter.parenthesis",open:"(",close:")"}],keywords:["append","block","case","default","doctype","each","else","extends","for","if","in","include","mixin","typeof","unless","var","when"],tags:["a","abbr","acronym","address","area","article","aside","audio","b","base","basefont","bdi","bdo","blockquote","body","br","button","canvas","caption","center","cite","code","col","colgroup","command","datalist","dd","del","details","dfn","div","dl","dt","em","embed","fieldset","figcaption","figure","font","footer","form","frame","frameset","h1","h2","h3","h4","h5","h6","head","header","hgroup","hr","html","i","iframe","img","input","ins","keygen","kbd","label","li","link","map","mark","menu","meta","meter","nav","noframes","noscript","object","ol","optgroup","option","output","p","param","pre","progress","q","rp","rt","ruby","s","samp","script","section","select","small","source","span","strike","strong","style","sub","summary","sup","table","tbody","td","textarea","tfoot","th","thead","time","title","tr","tracks","tt","u","ul","video","wbr"],symbols:/[\+\-\*\%\&\|\!\=\/\.\,\:]+/,escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[[/^(\s*)([a-zA-Z_-][\w-]*)/,{cases:{"$2@tags":{cases:{"@eos":["","tag"],"@default":["",{token:"tag",next:"@tag.$1"}]}},"$2@keywords":["",{token:"keyword.$2"}],"@default":["",""]}}],[/^(\s*)(#[a-zA-Z_-][\w-]*)/,{cases:{"@eos":["","tag.id"],"@default":["",{token:"tag.id",next:"@tag.$1"}]}}],[/^(\s*)(\.[a-zA-Z_-][\w-]*)/,{cases:{"@eos":["","tag.class"],"@default":["",{token:"tag.class",next:"@tag.$1"}]}}],[/^(\s*)(\|.*)$/,""],{include:"@whitespace"},[/[a-zA-Z_$][\w$]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":""}}],[/[{}()\[\]]/,"@brackets"],[/@symbols/,"delimiter"],[/\d+\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\d+/,"number"],[/"/,"string",'@string."'],[/'/,"string","@string.'"]],tag:[[/(\.)(\s*$)/,[{token:"delimiter",next:"@blockText.$S2."},""]],[/\s+/,{token:"",next:"@simpleText"}],[/#[a-zA-Z_-][\w-]*/,{cases:{"@eos":{token:"tag.id",next:"@pop"},"@default":"tag.id"}}],[/\.[a-zA-Z_-][\w-]*/,{cases:{"@eos":{token:"tag.class",next:"@pop"},"@default":"tag.class"}}],[/\(/,{token:"delimiter.parenthesis",next:"@attributeList"}]],simpleText:[[/[^#]+$/,{token:"",next:"@popall"}],[/[^#]+/,{token:""}],[/(#{)([^}]*)(})/,{cases:{"@eos":["interpolation.delimiter","interpolation",{token:"interpolation.delimiter",next:"@popall"}],"@default":["interpolation.delimiter","interpolation","interpolation.delimiter"]}}],[/#$/,{token:"",next:"@popall"}],[/#/,""]],attributeList:[[/\s+/,""],[/(\w+)(\s*=\s*)("|')/,["attribute.name","delimiter",{token:"attribute.value",next:"@value.$3"}]],[/\w+/,"attribute.name"],[/,/,{cases:{"@eos":{token:"attribute.delimiter",next:"@popall"},"@default":"attribute.delimiter"}}],[/\)$/,{token:"delimiter.parenthesis",next:"@popall"}],[/\)/,{token:"delimiter.parenthesis",next:"@pop"}]],whitespace:[[/^(\s*)(\/\/.*)$/,{token:"comment",next:"@blockText.$1.comment"}],[/[ \t\r\n]+/,""],[//,{token:"comment",next:"@pop"}],[//,"comment","@pop"],[/|$))/,T=d("^ {0,3}(?:<(script|pre|style|textarea)[\\s>][\\s\\S]*?(?:[^\\n]*\\n+|$)|comment[^\\n]*(\\n+|$)|<\\?[\\s\\S]*?(?:\\?>\\n*|$)|\\n*|$)|\\n*|$)|)[\\s\\S]*?(?:(?:\\n *)+\\n|$)|<(?!script|pre|style|textarea)([a-z][\\w-]*)(?:attribute)*? */?>(?=[ \\t]*(?:\\n|$))[\\s\\S]*?(?:(?:\\n *)+\\n|$)|(?=[ \\t]*(?:\\n|$))[\\s\\S]*?(?:(?:\\n *)+\\n|$))","i").replace("comment",L).replace("tag",R).replace("attribute",/ +[a-zA-Z:_][\w.:-]*(?: *= *"[^"\n]*"| *= *'[^'\n]*'| *= *[^\s"'=<>`]+)?/).getRegex(),x=d(b).replace("hr",v).replace("heading"," {0,3}#{1,6}(?:\\s|$)").replace("|lheading","").replace("|table","").replace("blockquote"," {0,3}>").replace("fences"," {0,3}(?:`{3,}(?=[^`\\n]*\\n)|~{3,})[^\\n]*\\n").replace("list"," {0,3}(?:[*+-]|1[.)]) ").replace("html",")|<(?:script|pre|style|textarea|!--)").replace("tag",R).getRegex(),k={blockquote:d(/^( {0,3}> ?(paragraph|[^\n]*)(?:\n|$))+/).replace("paragraph",x).getRegex(),code:/^( {4}[^\n]+(?:\n(?: *(?:\n|$))*)?)+/,def:y,fences:/^ {0,3}(`{3,}(?=[^`\n]*(?:\n|$))|~{3,})([^\n]*)(?:\n|$)(?:|([\s\S]*?)(?:\n|$))(?: {0,3}\1[~`]* *(?=\n|$)|$)/,heading:/^ {0,3}(#{1,6})(?=\s|$)(.*)(?:\n+|$)/,hr:v,html:T,lheading:E,list:w,newline:/^(?: *(?:\n|$))+/,paragraph:x,table:g,text:/^[^\n]+/},A=d("^ *([^\\n ].*)\\n {0,3}((?:\\| *)?:?-+:? *(?:\\| *:?-+:? *)*(?:\\| *)?)(?:\\n((?:(?! *\\n|hr|heading|blockquote|code|fences|list|html).*(?:\\n|$))*)\\n*|$)").replace("hr",v).replace("heading"," {0,3}#{1,6}(?:\\s|$)").replace("blockquote"," {0,3}>").replace("code"," {4}[^\\n]").replace("fences"," {0,3}(?:`{3,}(?=[^`\\n]*\\n)|~{3,})[^\\n]*\\n").replace("list"," {0,3}(?:[*+-]|1[.)]) ").replace("html",")|<(?:script|pre|style|textarea|!--)").replace("tag",R).getRegex(),N={...k,table:A,paragraph:d(b).replace("hr",v).replace("heading"," {0,3}#{1,6}(?:\\s|$)").replace("|lheading","").replace("table",A).replace("blockquote"," {0,3}>").replace("fences"," {0,3}(?:`{3,}(?=[^`\\n]*\\n)|~{3,})[^\\n]*\\n").replace("list"," {0,3}(?:[*+-]|1[.)]) ").replace("html",")|<(?:script|pre|style|textarea|!--)").replace("tag",R).getRegex()},I={...k,html:d("^ *(?:comment *(?:\\n|\\s*$)|<(tag)[\\s\\S]+? *(?:\\n{2,}|\\s*$)|\\s]*)*?/?> *(?:\\n{2,}|\\s*$))").replace("comment",L).replace(/tag/g,"(?!(?:a|em|strong|small|s|cite|q|dfn|abbr|data|time|code|var|samp|kbd|sub|sup|i|b|u|mark|ruby|rt|rp|bdi|bdo|span|br|wbr|ins|del|img)\\b)\\w+(?!:|[^\\w\\s@]*@)\\b").getRegex(),def:/^ *\[([^\]]+)\]: *]+)>?(?: +(["(][^\n]+[")]))? *(?:\n+|$)/,heading:/^(#{1,6})(.*)(?:\n+|$)/,fences:g,lheading:/^(.+?)\n {0,3}(=+|-+) *(?:\n+|$)/,paragraph:d(b).replace("hr",v).replace("heading"," *#{1,6} *[^\n]").replace("lheading",E).replace("|table","").replace("blockquote"," {0,3}>").replace("|fences","").replace("|list","").replace("|html","").replace("|tag","").getRegex()},O=/^\\([!"#$%&'()*+,\-./:;<=>?@\[\]\\^_`{|}~])/,D=/^( {2,}|\\)\n(?!\s*$)/,M="\\p{P}\\p{S}",P=d(/^((?![*_])[\spunctuation])/,"u").replace(/punctuation/g,M).getRegex(),F=d(/^(?:\*+(?:((?!\*)[punct])|[^\s*]))|^_+(?:((?!_)[punct])|([^\s_]))/,"u").replace(/punct/g,M).getRegex(),U=d("^[^_*]*?__[^_*]*?\\*[^_*]*?(?=__)|[^*]+(?=[^*])|(?!\\*)[punct](\\*+)(?=[\\s]|$)|[^punct\\s](\\*+)(?!\\*)(?=[punct\\s]|$)|(?!\\*)[punct\\s](\\*+)(?=[^punct\\s])|[\\s](\\*+)(?!\\*)(?=[punct])|(?!\\*)[punct](\\*+)(?!\\*)(?=[punct])|[^punct\\s](\\*+)(?=[^punct\\s])","gu").replace(/punct/g,M).getRegex(),H=d("^[^_*]*?\\*\\*[^_*]*?_[^_*]*?(?=\\*\\*)|[^_]+(?=[^_])|(?!_)[punct](_+)(?=[\\s]|$)|[^punct\\s](_+)(?!_)(?=[punct\\s]|$)|(?!_)[punct\\s](_+)(?=[^punct\\s])|[\\s](_+)(?!_)(?=[punct])|(?!_)[punct](_+)(?!_)(?=[punct])","gu").replace(/punct/g,M).getRegex(),B=d(/\\([punct])/,"gu").replace(/punct/g,M).getRegex(),W=d(/^<(scheme:[^\s\x00-\x1f<>]*|email)>/).replace("scheme",/[a-zA-Z][a-zA-Z0-9+.-]{1,31}/).replace("email",/[a-zA-Z0-9.!#$%&'*+/=?^_`{|}~-]+(@)[a-zA-Z0-9](?:[a-zA-Z0-9-]{0,61}[a-zA-Z0-9])?(?:\.[a-zA-Z0-9](?:[a-zA-Z0-9-]{0,61}[a-zA-Z0-9])?)+(?![-_])/).getRegex(),V=d(L).replace("(?:--\x3e|$)","--\x3e").getRegex(),z=d("^comment|^|^<[a-zA-Z][\\w-]*(?:attribute)*?\\s*/?>|^<\\?[\\s\\S]*?\\?>|^|^").replace("comment",V).replace("attribute",/\s+[a-zA-Z:_][\w.:-]*(?:\s*=\s*"[^"]*"|\s*=\s*'[^']*'|\s*=\s*[^\s"'=<>`]+)?/).getRegex(),G=/(?:\[(?:\\.|[^\[\]\\])*\]|\\.|`[^`]*`|[^\[\]\\`])*?/,j=d(/^!?\[(label)\]\(\s*(href)(?:\s+(title))?\s*\)/).replace("label",G).replace("href",/<(?:\\.|[^\n<>\\])+>|[^\s\x00-\x1f]*/).replace("title",/"(?:\\"?|[^"\\])*"|'(?:\\'?|[^'\\])*'|\((?:\\\)?|[^)\\])*\)/).getRegex(),K=d(/^!?\[(label)\]\[(ref)\]/).replace("label",G).replace("ref",S).getRegex(),Y=d(/^!?\[(ref)\](?:\[\])?/).replace("ref",S).getRegex(),q={_backpedal:g,anyPunctuation:B,autolink:W,blockSkip:/\[[^[\]]*?\]\([^\(\)]*?\)|`[^`]*?`|<[^<>]*?>/g,br:D,code:/^(`+)([^`]|[^`][\s\S]*?[^`])\1(?!`)/,del:g,emStrongLDelim:F,emStrongRDelimAst:U,emStrongRDelimUnd:H,escape:O,link:j,nolink:Y,punctuation:P,reflink:K,reflinkSearch:d("reflink|nolink(?!\\()","g").replace("reflink",K).replace("nolink",Y).getRegex(),tag:z,text:/^(`+|[^`])(?:(?= {2,}\n)|[\s\S]*?(?:(?=[\\t+" ".repeat(i.length)));e;)if(!(this.options.extensions&&this.options.extensions.block&&this.options.extensions.block.some((i=>!!(s=i.call({lexer:this},e,t))&&(e=e.substring(s.raw.length),t.push(s),!0)))))if(s=this.tokenizer.space(e))e=e.substring(s.raw.length),1===s.raw.length&&t.length>0?t[t.length-1].raw+="\n":t.push(s);else if(s=this.tokenizer.code(e))e=e.substring(s.raw.length),n=t[t.length-1],!n||"paragraph"!==n.type&&"text"!==n.type?t.push(s):(n.raw+="\n"+s.raw,n.text+="\n"+s.text,this.inlineQueue[this.inlineQueue.length-1].src=n.text);else if(s=this.tokenizer.fences(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.heading(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.hr(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.blockquote(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.list(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.html(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.def(e))e=e.substring(s.raw.length),n=t[t.length-1],!n||"paragraph"!==n.type&&"text"!==n.type?this.tokens.links[s.tag]||(this.tokens.links[s.tag]={href:s.href,title:s.title}):(n.raw+="\n"+s.raw,n.text+="\n"+s.raw,this.inlineQueue[this.inlineQueue.length-1].src=n.text);else if(s=this.tokenizer.table(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.lheading(e))e=e.substring(s.raw.length),t.push(s);else{if(r=e,this.options.extensions&&this.options.extensions.startBlock){let t=1/0;const i=e.slice(1);let s;this.options.extensions.startBlock.forEach((e=>{s=e.call({lexer:this},i),"number"===typeof s&&s>=0&&(t=Math.min(t,s))})),t<1/0&&t>=0&&(r=e.substring(0,t+1))}if(this.state.top&&(s=this.tokenizer.paragraph(r)))n=t[t.length-1],i&&"paragraph"===n?.type?(n.raw+="\n"+s.raw,n.text+="\n"+s.text,this.inlineQueue.pop(),this.inlineQueue[this.inlineQueue.length-1].src=n.text):t.push(s),i=r.length!==e.length,e=e.substring(s.raw.length);else if(s=this.tokenizer.text(e))e=e.substring(s.raw.length),n=t[t.length-1],n&&"text"===n.type?(n.raw+="\n"+s.raw,n.text+="\n"+s.text,this.inlineQueue.pop(),this.inlineQueue[this.inlineQueue.length-1].src=n.text):t.push(s);else if(e){const t="Infinite loop on byte: "+e.charCodeAt(0);if(this.options.silent){console.error(t);break}throw new Error(t)}}return this.state.top=!0,t}inline(e,t=[]){return this.inlineQueue.push({src:e,tokens:t}),t}inlineTokens(e,t=[]){let i,s,n,r,o,a,c=e;if(this.tokens.links){const e=Object.keys(this.tokens.links);if(e.length>0)for(;null!=(r=this.tokenizer.rules.inline.reflinkSearch.exec(c));)e.includes(r[0].slice(r[0].lastIndexOf("[")+1,-1))&&(c=c.slice(0,r.index)+"["+"a".repeat(r[0].length-2)+"]"+c.slice(this.tokenizer.rules.inline.reflinkSearch.lastIndex))}for(;null!=(r=this.tokenizer.rules.inline.blockSkip.exec(c));)c=c.slice(0,r.index)+"["+"a".repeat(r[0].length-2)+"]"+c.slice(this.tokenizer.rules.inline.blockSkip.lastIndex);for(;null!=(r=this.tokenizer.rules.inline.anyPunctuation.exec(c));)c=c.slice(0,r.index)+"++"+c.slice(this.tokenizer.rules.inline.anyPunctuation.lastIndex);for(;e;)if(o||(a=""),o=!1,!(this.options.extensions&&this.options.extensions.inline&&this.options.extensions.inline.some((s=>!!(i=s.call({lexer:this},e,t))&&(e=e.substring(i.raw.length),t.push(i),!0)))))if(i=this.tokenizer.escape(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.tag(e))e=e.substring(i.raw.length),s=t[t.length-1],s&&"text"===i.type&&"text"===s.type?(s.raw+=i.raw,s.text+=i.text):t.push(i);else if(i=this.tokenizer.link(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.reflink(e,this.tokens.links))e=e.substring(i.raw.length),s=t[t.length-1],s&&"text"===i.type&&"text"===s.type?(s.raw+=i.raw,s.text+=i.text):t.push(i);else if(i=this.tokenizer.emStrong(e,c,a))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.codespan(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.br(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.del(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.autolink(e))e=e.substring(i.raw.length),t.push(i);else if(this.state.inLink||!(i=this.tokenizer.url(e))){if(n=e,this.options.extensions&&this.options.extensions.startInline){let t=1/0;const i=e.slice(1);let s;this.options.extensions.startInline.forEach((e=>{s=e.call({lexer:this},i),"number"===typeof s&&s>=0&&(t=Math.min(t,s))})),t<1/0&&t>=0&&(n=e.substring(0,t+1))}if(i=this.tokenizer.inlineText(n))e=e.substring(i.raw.length),"_"!==i.raw.slice(-1)&&(a=i.raw.slice(-1)),o=!0,s=t[t.length-1],s&&"text"===s.type?(s.raw+=i.raw,s.text+=i.text):t.push(i);else if(e){const t="Infinite loop on byte: "+e.charCodeAt(0);if(this.options.silent){console.error(t);break}throw new Error(t)}}else e=e.substring(i.raw.length),t.push(i);return t}}class te{options;parser;constructor(t){this.options=t||e.defaults}space(e){return""}code({text:e,lang:t,escaped:i}){const s=(t||"").match(/^\S*/)?.[0],n=e.replace(/\n$/,"")+"\n";return s?'
'+(i?n:l(n,!0))+"
\n":"
"+(i?n:l(n,!0))+"
\n"}blockquote({tokens:e}){return`
\n${this.parser.parse(e)}
\n`}html({text:e}){return e}heading({tokens:e,depth:t}){return`${this.parser.parseInline(e)}\n`}hr(e){return"
\n"}list(e){const t=e.ordered,i=e.start;let s="";for(let r=0;r\n"+s+"\n"}listitem(e){let t="";if(e.task){const i=this.checkbox({checked:!!e.checked});e.loose?e.tokens.length>0&&"paragraph"===e.tokens[0].type?(e.tokens[0].text=i+" "+e.tokens[0].text,e.tokens[0].tokens&&e.tokens[0].tokens.length>0&&"text"===e.tokens[0].tokens[0].type&&(e.tokens[0].tokens[0].text=i+" "+e.tokens[0].tokens[0].text)):e.tokens.unshift({type:"text",raw:i+" ",text:i+" "}):t+=i+" "}return t+=this.parser.parse(e.tokens,!!e.loose),`
  • ${t}
  • \n`}checkbox({checked:e}){return"'}paragraph({tokens:e}){return`

    ${this.parser.parseInline(e)}

    \n`}table(e){let t="",i="";for(let n=0;n${s}`),"\n\n"+t+"\n"+s+"
    \n"}tablerow({text:e}){return`\n${e}\n`}tablecell(e){const t=this.parser.parseInline(e.tokens),i=e.header?"th":"td";return(e.align?`<${i} align="${e.align}">`:`<${i}>`)+t+`\n`}strong({tokens:e}){return`${this.parser.parseInline(e)}`}em({tokens:e}){return`${this.parser.parseInline(e)}`}codespan({text:e}){return`${e}`}br(e){return"
    "}del({tokens:e}){return`${this.parser.parseInline(e)}`}link({href:e,title:t,tokens:i}){const s=this.parser.parseInline(i),n=u(e);if(null===n)return s;let r='",r}image({href:e,title:t,text:i}){const s=u(e);if(null===s)return i;let n=`${i}{const n=e[s].flat(1/0);i=i.concat(this.walkTokens(n,t))})):e.tokens&&(i=i.concat(this.walkTokens(e.tokens,t)))}}return i}use(...e){const t=this.defaults.extensions||{renderers:{},childTokens:{}};return e.forEach((e=>{const i={...e};if(i.async=this.defaults.async||i.async||!1,e.extensions&&(e.extensions.forEach((e=>{if(!e.name)throw new Error("extension name required");if("renderer"in e){const i=t.renderers[e.name];t.renderers[e.name]=i?function(...t){let s=e.renderer.apply(this,t);return!1===s&&(s=i.apply(this,t)),s}:e.renderer}if("tokenizer"in e){if(!e.level||"block"!==e.level&&"inline"!==e.level)throw new Error("extension level must be 'block' or 'inline'");const i=t[e.level];i?i.unshift(e.tokenizer):t[e.level]=[e.tokenizer],e.start&&("block"===e.level?t.startBlock?t.startBlock.push(e.start):t.startBlock=[e.start]:"inline"===e.level&&(t.startInline?t.startInline.push(e.start):t.startInline=[e.start]))}"childTokens"in e&&e.childTokens&&(t.childTokens[e.name]=e.childTokens)})),i.extensions=t),e.renderer){const t=this.defaults.renderer||new te(this.defaults);for(const i in e.renderer){if(!(i in t))throw new Error(`renderer '${i}' does not exist`);if(["options","parser"].includes(i))continue;const s=i,n=e.renderer[s],r=t[s];t[s]=(...e)=>{let i=n.apply(t,e);return!1===i&&(i=r.apply(t,e)),i||""}}i.renderer=t}if(e.tokenizer){const t=this.defaults.tokenizer||new _(this.defaults);for(const i in e.tokenizer){if(!(i in t))throw new Error(`tokenizer '${i}' does not exist`);if(["options","rules","lexer"].includes(i))continue;const s=i,n=e.tokenizer[s],r=t[s];t[s]=(...e)=>{let i=n.apply(t,e);return!1===i&&(i=r.apply(t,e)),i}}i.tokenizer=t}if(e.hooks){const t=this.defaults.hooks||new ne;for(const i in e.hooks){if(!(i in t))throw new Error(`hook '${i}' does not exist`);if("options"===i)continue;const s=i,n=e.hooks[s],r=t[s];ne.passThroughHooks.has(i)?t[s]=e=>{if(this.defaults.async)return Promise.resolve(n.call(t,e)).then((e=>r.call(t,e)));const i=n.call(t,e);return r.call(t,i)}:t[s]=(...e)=>{let i=n.apply(t,e);return!1===i&&(i=r.apply(t,e)),i}}i.hooks=t}if(e.walkTokens){const t=this.defaults.walkTokens,s=e.walkTokens;i.walkTokens=function(e){let i=[];return i.push(s.call(this,e)),t&&(i=i.concat(t.call(this,e))),i}}this.defaults={...this.defaults,...i}})),this}setOptions(e){return this.defaults={...this.defaults,...e},this}lexer(e,t){return ee.lex(e,t??this.defaults)}parser(e,t){return se.parse(e,t??this.defaults)}parseMarkdown(e,t){return(i,s)=>{const n={...s},r={...this.defaults,...n},o=this.onError(!!r.silent,!!r.async);if(!0===this.defaults.async&&!1===n.async)return o(new Error("marked(): The async option was set to true by an extension. Remove async: false from the parse options object to return a Promise."));if("undefined"===typeof i||null===i)return o(new Error("marked(): input parameter is undefined or null"));if("string"!==typeof i)return o(new Error("marked(): input parameter is of type "+Object.prototype.toString.call(i)+", string expected"));if(r.hooks&&(r.hooks.options=r),r.async)return Promise.resolve(r.hooks?r.hooks.preprocess(i):i).then((t=>e(t,r))).then((e=>r.hooks?r.hooks.processAllTokens(e):e)).then((e=>r.walkTokens?Promise.all(this.walkTokens(e,r.walkTokens)).then((()=>e)):e)).then((e=>t(e,r))).then((e=>r.hooks?r.hooks.postprocess(e):e)).catch(o);try{r.hooks&&(i=r.hooks.preprocess(i));let s=e(i,r);r.hooks&&(s=r.hooks.processAllTokens(s)),r.walkTokens&&this.walkTokens(s,r.walkTokens);let n=t(s,r);return r.hooks&&(n=r.hooks.postprocess(n)),n}catch(a){return o(a)}}}onError(e,t){return i=>{if(i.message+="\nPlease report this to https://github.com/markedjs/marked.",e){const e="

    An error occurred:

    "+l(i.message+"",!0)+"
    ";return t?Promise.resolve(e):e}if(t)return Promise.reject(i);throw i}}}const oe=new re;function ae(e,t){return oe.parse(e,t)}ae.options=ae.setOptions=function(e){return oe.setOptions(e),ae.defaults=oe.defaults,i(ae.defaults),ae},ae.getDefaults=t,ae.defaults=e.defaults,ae.use=function(...e){return oe.use(...e),ae.defaults=oe.defaults,i(ae.defaults),ae},ae.walkTokens=function(e,t){return oe.walkTokens(e,t)},ae.parseInline=oe.parseInline,ae.Parser=se,ae.parser=se.parse,ae.Renderer=te,ae.TextRenderer=ie,ae.Lexer=ee,ae.lexer=ee.lex,ae.Tokenizer=_,ae.Hooks=ne,ae.parse=ae;const ce=ae.options,le=ae.setOptions,he=ae.use,de=ae.walkTokens,ue=ae.parseInline,ge=ae,pe=se.parse,me=ee.lex;e.Hooks=ne,e.Lexer=ee,e.Marked=re,e.Parser=se,e.Renderer=te,e.TextRenderer=ie,e.Tokenizer=_,e.getDefaults=t,e.lexer=me,e.marked=ae,e.options=ce,e.parse=ge,e.parseInline=ue,e.parser=pe,e.setOptions=le,e.use=he,e.walkTokens=de},e.amd?e(0,i):"object"===typeof exports?i(exports):i((t="undefined"!==typeof globalThis?globalThis:t||self).marked={})}();_.Hooks||exports.Hooks,_.Lexer||exports.Lexer,_.Marked||exports.Marked,_.Parser||exports.Parser;var v=_.Renderer||exports.Renderer,C=(_.TextRenderer||exports.TextRenderer,_.Tokenizer||exports.Tokenizer,_.defaults||exports.defaults),E=(_.getDefaults||exports.getDefaults,_.lexer||exports.lexer),b=(_.marked||exports.marked,_.options||exports.options,_.parse||exports.parse),S=(_.parseInline||exports.parseInline,_.parser||exports.parser),y=(_.setOptions||exports.setOptions,_.use||exports.use,_.walkTokens||exports.walkTokens,i(908)),w=i(36456),R=i(10146),L=i(89403),T=i(91508),x=i(79400);const k=Object.freeze({image:({href:e,title:t,text:i})=>{let s=[],n=[];return e&&(({href:e,dimensions:s}=(0,u.nI)(e)),n.push(`src="${(0,u.oO)(e)}"`)),i&&n.push(`alt="${(0,u.oO)(i)}"`),t&&n.push(`title="${(0,u.oO)(t)}"`),s.length&&(n=n.concat(s)),""},paragraph({tokens:e}){return`

    ${this.parser.parseInline(e)}

    `},link({href:e,title:t,tokens:i}){let s=this.parser.parseInline(i);return"string"!==typeof e?"":(e===s&&(s=(0,u._W)(s)),t="string"===typeof t?(0,u.oO)((0,u._W)(t)):"",`
    /g,">").replace(/"/g,""").replace(/'/g,"'")}" title="${t||e}" draggable="false">${s}`)}});function A(e,t={},i={}){const n=new f.Cm;let u=!1;const m=(0,o.n)(t),_=function(t){let i;try{i=(0,y.qg)(decodeURIComponent(t))}catch(s){}return i?(i=(0,R.PI)(i,(t=>e.uris&&e.uris[t]?x.r.revive(e.uris[t]):void 0)),encodeURIComponent(JSON.stringify(i))):t},L=function(t,i){const s=e.uris&&e.uris[t];let n=x.r.revive(s);return i?t.startsWith(w.ny.data+":")?t:(n||(n=x.r.parse(t)),w.zl.uriToBrowserUri(n).toString(!0)):n?x.r.parse(t).toString()===n.toString()?t:(n.query&&(n=n.with({query:_(n.query)})),n.toString()):t},A=new v;A.image=k.image,A.link=k.link,A.paragraph=k.paragraph;const O=[],M=[];if(t.codeBlockRendererSync?A.code=({text:e,lang:i})=>{const s=p.r.nextId(),n=t.codeBlockRendererSync(N(i),e);return M.push([s,n]),`
    ${(0,T.ih)(e)}
    `}:t.codeBlockRenderer&&(A.code=({text:e,lang:i})=>{const s=p.r.nextId(),n=t.codeBlockRenderer(N(i),e);return O.push(n.then((e=>[s,e]))),`
    ${(0,T.ih)(e)}
    `}),t.actionHandler){const i=function(i){let s=i.target;if("A"===s.tagName||(s=s.parentElement,s&&"A"===s.tagName))try{let n=s.dataset.href;n&&(e.baseUri&&(n=I(x.r.from(e.baseUri),n)),t.actionHandler.callback(n,i))}catch(n){(0,h.dz)(n)}finally{i.preventDefault()}},n=t.actionHandler.disposables.add(new r.f(m,"click")),o=t.actionHandler.disposables.add(new r.f(m,"auxclick"));t.actionHandler.disposables.add(d.Jh.any(n.event,o.event)((e=>{const t=new c.P(s.zk(m),e);(t.leftButton||t.middleButton)&&i(t)}))),t.actionHandler.disposables.add(s.ko(m,"keydown",(e=>{const t=new a.Z(e);(t.equals(10)||t.equals(3))&&i(t)})))}e.supportHtml||(A.html=({text:i})=>{if(t.sanitizerOptions?.replaceWithPlaintext)return(0,T.ih)(i);return(e.isTrusted?i.match(/^(]+>)|(<\/\s*span>)$/):void 0)?i:""}),i.renderer=A;let P,F=e.value??"";if(F.length>1e5&&(F=`${F.substr(0,1e5)}\u2026`),e.supportThemeIcons&&(F=(0,g.sA)(F)),t.fillInIncompleteTokens){const e={...C,...i},t=function(e){for(let t=0;t"string"===typeof e?e:e.outerHTML)).join("")}const U=(new DOMParser).parseFromString(D({isTrusted:e.isTrusted,...t.sanitizerOptions},P),"text/html");if(U.body.querySelectorAll("img, audio, video, source").forEach((i=>{const n=i.getAttribute("src");if(n){let o=n;try{e.baseUri&&(o=I(x.r.from(e.baseUri),o))}catch(r){}if(i.setAttribute("src",L(o,!0)),t.remoteImageIsAllowed){const e=x.r.parse(o);e.scheme===w.ny.file||e.scheme===w.ny.data||t.remoteImageIsAllowed(e)||i.replaceWith(s.$("",void 0,i.outerHTML))}}})),U.body.querySelectorAll("a").forEach((t=>{const i=t.getAttribute("href");if(t.setAttribute("href",""),!i||/^data:|javascript:/i.test(i)||/^command:/i.test(i)&&!e.isTrusted||/^command:(\/\/\/)?_workbench\.downloadResource/i.test(i))t.replaceWith(...t.childNodes);else{let s=L(i,!1);e.baseUri&&(s=I(x.r.from(e.baseUri),i)),t.dataset.href=s}})),m.innerHTML=D({isTrusted:e.isTrusted,...t.sanitizerOptions},U.body.innerHTML),O.length>0)Promise.all(O).then((e=>{if(u)return;const i=new Map(e),n=m.querySelectorAll("div[data-code]");for(const t of n){const e=i.get(t.dataset.code??"");e&&s.Ln(t,e)}t.asyncRenderCallback?.()}));else if(M.length>0){const e=new Map(M),t=m.querySelectorAll("div[data-code]");for(const i of t){const t=e.get(i.dataset.code??"");t&&s.Ln(i,t)}}if(t.asyncRenderCallback)for(const r of m.getElementsByTagName("img")){const e=n.add(s.ko(r,"load",(()=>{e.dispose(),t.asyncRenderCallback()})))}return{element:m,dispose:()=>{u=!0,n.dispose()}}}function N(e){if(!e)return"";const t=e.split(/[\s+|:|,|\{|\?]/,1);return t.length?t[0]:e}function I(e,t){return/^\w[\w\d+.-]*:/.test(t)?t:e.path.endsWith("/")?(0,L.o1)(e,t).toString():(0,L.o1)((0,L.pD)(e),t).toString()}const O=["area","base","br","col","command","embed","hr","img","input","keygen","link","meta","param","source","track","wbr"];function D(e,t){const{config:i,allowedSchemes:r}=function(e){const t=[w.ny.http,w.ny.https,w.ny.mailto,w.ny.data,w.ny.file,w.ny.vscodeFileResource,w.ny.vscodeRemote,w.ny.vscodeRemoteResource];e.isTrusted&&t.push(w.ny.command);return{config:{ALLOWED_TAGS:e.allowedTags??[...s.TT],ALLOWED_ATTR:M,ALLOW_UNKNOWN_PROTOCOLS:!0},allowedSchemes:t}}(e),o=new f.Cm;o.add(ie("uponSanitizeAttribute",((e,t)=>{if("style"!==t.attrName&&"class"!==t.attrName){if("INPUT"===e.tagName&&"checkbox"===e.attributes.getNamedItem("type")?.value){if("type"===t.attrName&&"checkbox"===t.attrValue||"disabled"===t.attrName||"checked"===t.attrName)return void(t.keepAttr=!0);t.keepAttr=!1}}else{if("SPAN"===e.tagName){if("style"===t.attrName)return void(t.keepAttr=/^(color\:(#[0-9a-fA-F]+|var\(--vscode(-[a-zA-Z]+)+\));)?(background-color\:(#[0-9a-fA-F]+|var\(--vscode(-[a-zA-Z]+)+\));)?(border-radius:[0-9]+px;)?$/.test(t.attrValue));if("class"===t.attrName)return void(t.keepAttr=/^codicon codicon-[a-z\-]+( codicon-modifier-[a-z\-]+)?$/.test(t.attrValue))}t.keepAttr=!1}}))),o.add(ie("uponSanitizeElement",((t,i)=>{if("input"===i.tagName&&("checkbox"===t.attributes.getNamedItem("type")?.value?t.setAttribute("disabled",""):e.replaceWithPlaintext||t.remove()),e.replaceWithPlaintext&&!i.allowedTags[i.tagName]&&"body"!==i.tagName&&t.parentElement){let e,s;if("#comment"===i.tagName)e=`\x3c!--${t.textContent}--\x3e`;else{const n=O.includes(i.tagName),r=t.attributes.length?" "+Array.from(t.attributes).map((e=>`${e.name}="${e.value}"`)).join(" "):"";e=`<${i.tagName}${r}>`,n||(s=``)}const n=document.createDocumentFragment(),r=t.parentElement.ownerDocument.createTextNode(e);n.appendChild(r);const o=s?t.parentElement.ownerDocument.createTextNode(s):void 0;for(;t.firstChild;)n.appendChild(t.firstChild);o&&n.appendChild(o),t.nodeType===Node.COMMENT_NODE?t.parentElement.insertBefore(n,t):t.parentElement.replaceChild(n,t)}}))),o.add(s.a4(r));try{return n.aj(t,{...i,RETURN_TRUSTED_TYPE:!0})}finally{o.dispose()}}const M=["align","autoplay","alt","checked","class","colspan","controls","data-code","data-href","disabled","draggable","height","href","loop","muted","playsinline","poster","rowspan","src","style","target","title","type","width","start"];function P(e){return"string"===typeof e?e:function(e,t){let i=e.value??"";i.length>1e5&&(i=`${i.substr(0,1e5)}\u2026`);return D({isTrusted:!1},b(i,{async:!1,renderer:t?B.value:H.value}).replace(/&(#\d+|[a-zA-Z]+);/g,(e=>F.get(e)??e))).toString()}(e)}const F=new Map([[""",'"'],[" "," "],["&","&"],["'","'"],["<","<"],[">",">"]]);function U(){const e=new v;return e.code=({text:e})=>e,e.blockquote=({text:e})=>e+"\n",e.html=e=>"",e.heading=function({tokens:e}){return this.parser.parseInline(e)+"\n"},e.hr=()=>"",e.list=function({items:e}){return e.map((e=>this.listitem(e))).join("\n")+"\n"},e.listitem=({text:e})=>e+"\n",e.paragraph=function({tokens:e}){return this.parser.parseInline(e)+"\n"},e.table=function({header:e,rows:t}){return e.map((e=>this.tablecell(e))).join(" ")+"\n"+t.map((e=>e.map((e=>this.tablecell(e))).join(" "))).join("\n")+"\n"},e.tablerow=({text:e})=>e,e.tablecell=function({tokens:e}){return this.parser.parseInline(e)},e.strong=({text:e})=>e,e.em=({text:e})=>e,e.codespan=({text:e})=>e,e.br=e=>"\n",e.del=({text:e})=>e,e.image=e=>"",e.text=({text:e})=>e,e.link=({text:e})=>e,e}const H=new m.d((e=>U())),B=new m.d((()=>{const e=U();return e.code=({text:e})=>`\n\`\`\`\n${e}\n\`\`\`\n`,e}));function W(e){let t="";return e.forEach((e=>{t+=e.raw})),t}function V(e){if(e.tokens)for(let t=e.tokens.length-1;t>=0;t--){const i=e.tokens[t];if("text"===i.type){const s=i.raw.split("\n"),n=s[s.length-1];if(n.includes("`"))return Y(e);if(n.includes("**"))return ee(e,"**");if(n.match(/\*\w/))return q(e);if(n.match(/(^|\s)__\w/))return J(e);if(n.match(/(^|\s)_\w/))return $(e);if(n.match(/(^|\s)\[.*\]\(\w*/)||z(n)&&e.tokens.slice(0,t).some((e=>"text"===e.type&&e.raw.match(/\[[^\]]*$/)))){const i=e.tokens.slice(t+1);return"link"===i[0]?.type&&"text"===i[1]?.type&&i[1].raw.match(/^ *"[^"]*$/)||n.match(/^[^"]* +"[^"]*$/)?X(e):Q(e)}if(n.match(/(^|\s)\[\w*/))return Z(e)}}}function z(e){return!!e.match(/^[^\[]*\]\([^\)]*$/)}function G(e){const t=e.items[e.items.length-1],i=t.tokens?t.tokens[t.tokens.length-1]:void 0;let s;if("text"!==i?.type||"inRawBlock"in t||(s=V(i)),!s||"paragraph"!==s.type)return;const n=W(e.items.slice(0,-1)),r=t.raw.match(/^(\s*(-|\d+\.|\*) +)/)?.[0];if(!r)return;const o=r+W(t.tokens.slice(0,-1))+s.raw,a=E(n+o)[0];return"list"===a.type?a:void 0}const j=3;function K(e){let t,i;for(t=0;t0){const e=n?i.slice(0,-1).join("\n"):t,r=!!e.match(/\|\s*$/),o=e+(r?"":"|")+`\n|${" --- |".repeat(s)}`;return E(o)}}function ie(e,t){return n.$w(e,t),(0,f.s)((()=>n.SV(e)))}},68250:(e,t,i)=>{"use strict";i.d(t,{u:()=>L});var s=i(90766),n=i(16980),r=i(83069),o=i(87289),a=i(57039),c=i(10154),l=i(18938),h=i(7142),d=i(57286),u=i(21478),g=i(84001),p=i(49099),m=i(56942),f=i(78209),_=i(98067),v=i(3730),C=i(25890),E=i(98031),b=i(67220),S=i(50091),y=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},w=function(e,t){return function(i,s){t(i,s,e)}};class R extends a.mm{constructor(e,t,i,s){super(10,t,e.item.anchor.range,i,s,!0),this.part=e}}let L=class extends d.xJ{constructor(e,t,i,s,n,r,o,a,c){super(e,t,i,r,a,s,n,c),this._resolverService=o,this.hoverOrdinal=6}suggestHoverAnchor(e){if(!u.M.get(this._editor))return null;if(6!==e.target.type)return null;const t=e.target.detail.injectedText?.options;return t instanceof o.Ho&&t.attachedData instanceof u.z?new R(t.attachedData,this,e.event.posx,e.event.posy):null}computeSync(){return[]}computeAsync(e,t,i){return e instanceof R?new s.AE((async t=>{const{part:s}=e;if(await s.item.resolve(i),i.isCancellationRequested)return;let r,o;if("string"===typeof s.item.hint.tooltip?r=(new n.Bc).appendText(s.item.hint.tooltip):s.item.hint.tooltip&&(r=s.item.hint.tooltip),r&&t.emitOne(new d.eH(this,e.range,[r],!1,0)),(0,C.EI)(s.item.hint.textEdits)&&t.emitOne(new d.eH(this,e.range,[(new n.Bc).appendText((0,f.kg)("hint.dbl","Double-click to insert"))],!1,10001)),"string"===typeof s.part.tooltip?o=(new n.Bc).appendText(s.part.tooltip):s.part.tooltip&&(o=s.part.tooltip),o&&t.emitOne(new d.eH(this,e.range,[o],!1,1)),s.part.location||s.part.command){let i;const r="altKey"===this._editor.getOption(78)?_.zx?(0,f.kg)("links.navigate.kb.meta.mac","cmd + click"):(0,f.kg)("links.navigate.kb.meta","ctrl + click"):_.zx?(0,f.kg)("links.navigate.kb.alt.mac","option + click"):(0,f.kg)("links.navigate.kb.alt","alt + click");s.part.location&&s.part.command?i=(new n.Bc).appendText((0,f.kg)("hint.defAndCommand","Go to Definition ({0}), right click for more",r)):s.part.location?i=(new n.Bc).appendText((0,f.kg)("hint.def","Go to Definition ({0})",r)):s.part.command&&(i=new n.Bc(`[${(0,f.kg)("hint.cmd","Execute Command")}](${(0,v.CN)(s.part.command)} "${s.part.command.title}") (${r})`,{isTrusted:!0})),i&&t.emitOne(new d.eH(this,e.range,[i],!1,1e4))}const a=await this._resolveInlayHintLabelPartHover(s,i);for await(const e of a)t.emitOne(e)})):s.AE.EMPTY}async _resolveInlayHintLabelPartHover(e,t){if(!e.part.location)return s.AE.EMPTY;const{uri:i,range:o}=e.part.location,a=await this._resolverService.createModelReference(i);try{const i=a.object.textEditorModel;return this._languageFeaturesService.hoverProvider.has(i)?(0,h.U)(this._languageFeaturesService.hoverProvider,i,new r.y(o.startLineNumber,o.startColumn),t).filter((e=>!(0,n.it)(e.hover.contents))).map((t=>new d.eH(this,e.item.anchor.range,t.hover.contents,!1,2+t.ordinal))):s.AE.EMPTY}finally{a.dispose()}}};L=y([w(1,c.L),w(2,p.C),w(3,E.b),w(4,b.TN),w(5,g.pG),w(6,l.ITextModelService),w(7,m.ILanguageFeaturesService),w(8,S.d)],L)},68310:(e,t,i)=>{"use strict";i.d(t,{R:()=>g,j:()=>u});var s=i(18447),n=i(64383),r=i(79400),o=i(36677),a=i(23750),c=i(50091),l=i(56942),h=i(52363),d=i(84001);async function u(e,t,i,s=!0){return _(new p,e,t,i,s)}function g(e,t,i,s){return Promise.resolve(i.provideColorPresentations(e,t,s))}class p{constructor(){}async compute(e,t,i,s){const n=await e.provideDocumentColors(t,i);if(Array.isArray(n))for(const r of n)s.push({colorInfo:r,provider:e});return Array.isArray(n)}}class m{constructor(){}async compute(e,t,i,s){const n=await e.provideDocumentColors(t,i);if(Array.isArray(n))for(const r of n)s.push({range:r.range,color:[r.color.red,r.color.green,r.color.blue,r.color.alpha]});return Array.isArray(n)}}class f{constructor(e){this.colorInfo=e}async compute(e,t,i,n){const r=await e.provideColorPresentations(t,this.colorInfo,s.XO.None);return Array.isArray(r)&&n.push(...r),Array.isArray(r)}}async function _(e,t,i,s,r){let o,a=!1;const c=[],l=t.ordered(i);for(let u=l.length-1;u>=0;u--){const t=l[u];if(t instanceof h.L)o=t;else try{await e.compute(t,i,s,c)&&(a=!0)}catch(d){(0,n.M_)(d)}}return a?c:o&&r?(await e.compute(o,i,s,c),c):[]}function v(e,t){const{colorProvider:i}=e.get(l.ILanguageFeaturesService),s=e.get(a.IModelService).getModel(t);if(!s)throw(0,n.Qg)();return{model:s,colorProviderRegistry:i,isDefaultColorDecoratorsEnabled:e.get(d.pG).getValue("editor.defaultColorDecorators",{resource:t})}}c.w.registerCommand("_executeDocumentColorProvider",(function(e,...t){const[i]=t;if(!(i instanceof r.r))throw(0,n.Qg)();const{model:o,colorProviderRegistry:a,isDefaultColorDecoratorsEnabled:c}=v(e,i);return _(new m,a,o,s.XO.None,c)})),c.w.registerCommand("_executeColorPresentationProvider",(function(e,...t){const[i,a]=t,{uri:c,range:l}=a;if(!(c instanceof r.r)||!Array.isArray(i)||4!==i.length||!o.Q.isIRange(l))throw(0,n.Qg)();const{model:h,colorProviderRegistry:d,isDefaultColorDecoratorsEnabled:u}=v(e,c),[g,p,m,C]=i;return _(new f({range:l,color:{red:g,green:p,blue:m,alpha:C}}),d,h,s.XO.None,u)}))},68792:(e,t,i)=>{"use strict";i.d(t,{$D:()=>s,Eq:()=>E,M0:()=>R,Mz:()=>w,No:()=>y,bs:()=>b});var s,n=i(60413),r=i(8597),o=i(56245),a=i(72962),c=i(5239),l=i(90766),h=i(41234),d=i(5662),u=i(44320),g=i(91508),p=i(69785),m=i(75326),f=i(253),_=i(18801),v=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},C=function(e,t){return function(i,s){t(i,s,e)}};!function(e){e.Tap="-monaco-textarea-synthetic-tap"}(s||(s={}));const E={forceCopyWithSyntaxHighlighting:!1};class b{static{this.INSTANCE=new b}constructor(){this._lastState=null}set(e,t){this._lastState={lastCopiedValue:e,data:t}}get(e){return this._lastState&&this._lastState.lastCopiedValue===e?this._lastState.data:(this._lastState=null,null)}}class S{constructor(){this._lastTypeTextLength=0}handleCompositionUpdate(e){const t={text:e=e||"",replacePrevCharCnt:this._lastTypeTextLength,replaceNextCharCnt:0,positionDelta:0};return this._lastTypeTextLength=e.length,t}}let y=class extends d.jG{get textAreaState(){return this._textAreaState}constructor(e,t,i,s,n,r){super(),this._host=e,this._textArea=t,this._OS=i,this._browser=s,this._accessibilityService=n,this._logService=r,this._onFocus=this._register(new h.vl),this.onFocus=this._onFocus.event,this._onBlur=this._register(new h.vl),this.onBlur=this._onBlur.event,this._onKeyDown=this._register(new h.vl),this.onKeyDown=this._onKeyDown.event,this._onKeyUp=this._register(new h.vl),this.onKeyUp=this._onKeyUp.event,this._onCut=this._register(new h.vl),this.onCut=this._onCut.event,this._onPaste=this._register(new h.vl),this.onPaste=this._onPaste.event,this._onType=this._register(new h.vl),this.onType=this._onType.event,this._onCompositionStart=this._register(new h.vl),this.onCompositionStart=this._onCompositionStart.event,this._onCompositionUpdate=this._register(new h.vl),this.onCompositionUpdate=this._onCompositionUpdate.event,this._onCompositionEnd=this._register(new h.vl),this.onCompositionEnd=this._onCompositionEnd.event,this._onSelectionChangeRequest=this._register(new h.vl),this.onSelectionChangeRequest=this._onSelectionChangeRequest.event,this._asyncFocusGainWriteScreenReaderContent=this._register(new d.HE),this._asyncTriggerCut=this._register(new l.uC((()=>this._onCut.fire()),0)),this._textAreaState=p._O.EMPTY,this._selectionChangeListener=null,this._accessibilityService.isScreenReaderOptimized()&&this.writeNativeTextAreaContent("ctor"),this._register(h.Jh.runAndSubscribe(this._accessibilityService.onDidChangeScreenReaderOptimized,(()=>{this._accessibilityService.isScreenReaderOptimized()&&!this._asyncFocusGainWriteScreenReaderContent.value?this._asyncFocusGainWriteScreenReaderContent.value=this._register(new l.uC((()=>this.writeNativeTextAreaContent("asyncFocusGain")),0)):this._asyncFocusGainWriteScreenReaderContent.clear()}))),this._hasFocus=!1,this._currentComposition=null;let o=null;this._register(this._textArea.onKeyDown((e=>{const t=new a.Z(e);(114===t.keyCode||this._currentComposition&&1===t.keyCode)&&t.stopPropagation(),t.equals(9)&&t.preventDefault(),o=t,this._onKeyDown.fire(t)}))),this._register(this._textArea.onKeyUp((e=>{const t=new a.Z(e);this._onKeyUp.fire(t)}))),this._register(this._textArea.onCompositionStart((e=>{p.Hf&&console.log("[compositionstart]",e);const t=new S;if(this._currentComposition)this._currentComposition=t;else{if(this._currentComposition=t,2===this._OS&&o&&o.equals(114)&&this._textAreaState.selectionStart===this._textAreaState.selectionEnd&&this._textAreaState.selectionStart>0&&this._textAreaState.value.substr(this._textAreaState.selectionStart-1,1)===e.data&&("ArrowRight"===o.code||"ArrowLeft"===o.code))return p.Hf&&console.log("[compositionstart] Handling long press case on macOS + arrow key",e),t.handleCompositionUpdate("x"),void this._onCompositionStart.fire({data:e.data});this._browser.isAndroid,this._onCompositionStart.fire({data:e.data})}}))),this._register(this._textArea.onCompositionUpdate((e=>{p.Hf&&console.log("[compositionupdate]",e);const t=this._currentComposition;if(!t)return;if(this._browser.isAndroid){const t=p._O.readFromTextArea(this._textArea,this._textAreaState),i=p._O.deduceAndroidCompositionInput(this._textAreaState,t);return this._textAreaState=t,this._onType.fire(i),void this._onCompositionUpdate.fire(e)}const i=t.handleCompositionUpdate(e.data);this._textAreaState=p._O.readFromTextArea(this._textArea,this._textAreaState),this._onType.fire(i),this._onCompositionUpdate.fire(e)}))),this._register(this._textArea.onCompositionEnd((e=>{p.Hf&&console.log("[compositionend]",e);const t=this._currentComposition;if(!t)return;if(this._currentComposition=null,this._browser.isAndroid){const e=p._O.readFromTextArea(this._textArea,this._textAreaState),t=p._O.deduceAndroidCompositionInput(this._textAreaState,e);return this._textAreaState=e,this._onType.fire(t),void this._onCompositionEnd.fire()}const i=t.handleCompositionUpdate(e.data);this._textAreaState=p._O.readFromTextArea(this._textArea,this._textAreaState),this._onType.fire(i),this._onCompositionEnd.fire()}))),this._register(this._textArea.onInput((e=>{if(p.Hf&&console.log("[input]",e),this._textArea.setIgnoreSelectionChangeTime("received input event"),this._currentComposition)return;const t=p._O.readFromTextArea(this._textArea,this._textAreaState),i=p._O.deduceInput(this._textAreaState,t,2===this._OS);(0!==i.replacePrevCharCnt||1!==i.text.length||!g.pc(i.text.charCodeAt(0))&&127!==i.text.charCodeAt(0))&&(this._textAreaState=t,""===i.text&&0===i.replacePrevCharCnt&&0===i.replaceNextCharCnt&&0===i.positionDelta||this._onType.fire(i))}))),this._register(this._textArea.onCut((e=>{this._textArea.setIgnoreSelectionChangeTime("received cut event"),this._ensureClipboardGetsEditorSelection(e),this._asyncTriggerCut.schedule()}))),this._register(this._textArea.onCopy((e=>{this._ensureClipboardGetsEditorSelection(e)}))),this._register(this._textArea.onPaste((e=>{if(this._textArea.setIgnoreSelectionChangeTime("received paste event"),e.preventDefault(),!e.clipboardData)return;let[t,i]=w.getTextData(e.clipboardData);t&&(i=i||b.INSTANCE.get(t),this._onPaste.fire({text:t,metadata:i}))}))),this._register(this._textArea.onFocus((()=>{const e=this._hasFocus;this._setHasFocus(!0),this._accessibilityService.isScreenReaderOptimized()&&this._browser.isSafari&&!e&&this._hasFocus&&(this._asyncFocusGainWriteScreenReaderContent.value||(this._asyncFocusGainWriteScreenReaderContent.value=new l.uC((()=>this.writeNativeTextAreaContent("asyncFocusGain")),0)),this._asyncFocusGainWriteScreenReaderContent.value.schedule())}))),this._register(this._textArea.onBlur((()=>{this._currentComposition&&(this._currentComposition=null,this.writeNativeTextAreaContent("blurWithoutCompositionEnd"),this._onCompositionEnd.fire()),this._setHasFocus(!1)}))),this._register(this._textArea.onSyntheticTap((()=>{this._browser.isAndroid&&this._currentComposition&&(this._currentComposition=null,this.writeNativeTextAreaContent("tapWithoutCompositionEnd"),this._onCompositionEnd.fire())})))}_installSelectionChangeListener(){let e=0;return r.ko(this._textArea.ownerDocument,"selectionchange",(t=>{if(c.p.onSelectionChange(),!this._hasFocus)return;if(this._currentComposition)return;if(!this._browser.isChrome)return;const i=Date.now(),s=i-e;if(e=i,s<5)return;const n=i-this._textArea.getIgnoreSelectionChangeTime();if(this._textArea.resetSelectionChangeTime(),n<100)return;if(!this._textAreaState.selection)return;const r=this._textArea.getValue();if(this._textAreaState.value!==r)return;const o=this._textArea.getSelectionStart(),a=this._textArea.getSelectionEnd();if(this._textAreaState.selectionStart===o&&this._textAreaState.selectionEnd===a)return;const l=this._textAreaState.deduceEditorPosition(o),h=this._host.deduceModelPosition(l[0],l[1],l[2]),d=this._textAreaState.deduceEditorPosition(a),u=this._host.deduceModelPosition(d[0],d[1],d[2]),g=new m.L(h.lineNumber,h.column,u.lineNumber,u.column);this._onSelectionChangeRequest.fire(g)}))}dispose(){super.dispose(),this._selectionChangeListener&&(this._selectionChangeListener.dispose(),this._selectionChangeListener=null)}focusTextArea(){this._setHasFocus(!0),this.refreshFocusState()}isFocused(){return this._hasFocus}refreshFocusState(){this._setHasFocus(this._textArea.hasFocus())}_setHasFocus(e){this._hasFocus!==e&&(this._hasFocus=e,this._selectionChangeListener&&(this._selectionChangeListener.dispose(),this._selectionChangeListener=null),this._hasFocus&&(this._selectionChangeListener=this._installSelectionChangeListener()),this._hasFocus&&this.writeNativeTextAreaContent("focusgain"),this._hasFocus?this._onFocus.fire():this._onBlur.fire())}_setAndWriteTextAreaState(e,t){this._hasFocus||(t=t.collapseSelection()),t.writeToTextArea(e,this._textArea,this._hasFocus),this._textAreaState=t}writeNativeTextAreaContent(e){!this._accessibilityService.isScreenReaderOptimized()&&"render"===e||this._currentComposition||(this._logService.trace(`writeTextAreaState(reason: ${e})`),this._setAndWriteTextAreaState(e,this._host.getScreenReaderContent()))}_ensureClipboardGetsEditorSelection(e){const t=this._host.getDataToCopy(),i={version:1,isFromEmptySelection:t.isFromEmptySelection,multicursorText:t.multicursorText,mode:t.mode};b.INSTANCE.set(this._browser.isFirefox?t.text.replace(/\r\n/g,"\n"):t.text,i),e.preventDefault(),e.clipboardData&&w.setTextData(e.clipboardData,t.text,t.html,i)}};y=v([C(4,f.j),C(5,_.rr)],y);const w={getTextData(e){const t=e.getData(u.K.text);let i=null;const s=e.getData("vscode-editor-data");if("string"===typeof s)try{i=JSON.parse(s),1!==i.version&&(i=null)}catch(n){}if(0===t.length&&null===i&&e.files.length>0){return[Array.prototype.slice.call(e.files,0).map((e=>e.name)).join("\n"),null]}return[t,i]},setTextData(e,t,i,s){e.setData(u.K.text,t),"string"===typeof i&&e.setData("text/html",i),e.setData("vscode-editor-data",JSON.stringify(s))}};class R extends d.jG{get ownerDocument(){return this._actual.ownerDocument}constructor(e){super(),this._actual=e,this.onKeyDown=this._register(new o.f(this._actual,"keydown")).event,this.onKeyUp=this._register(new o.f(this._actual,"keyup")).event,this.onCompositionStart=this._register(new o.f(this._actual,"compositionstart")).event,this.onCompositionUpdate=this._register(new o.f(this._actual,"compositionupdate")).event,this.onCompositionEnd=this._register(new o.f(this._actual,"compositionend")).event,this.onBeforeInput=this._register(new o.f(this._actual,"beforeinput")).event,this.onInput=this._register(new o.f(this._actual,"input")).event,this.onCut=this._register(new o.f(this._actual,"cut")).event,this.onCopy=this._register(new o.f(this._actual,"copy")).event,this.onPaste=this._register(new o.f(this._actual,"paste")).event,this.onFocus=this._register(new o.f(this._actual,"focus")).event,this.onBlur=this._register(new o.f(this._actual,"blur")).event,this._onSyntheticTap=this._register(new h.vl),this.onSyntheticTap=this._onSyntheticTap.event,this._ignoreSelectionChangeTime=0,this._register(this.onKeyDown((()=>c.p.onKeyDown()))),this._register(this.onBeforeInput((()=>c.p.onBeforeInput()))),this._register(this.onInput((()=>c.p.onInput()))),this._register(this.onKeyUp((()=>c.p.onKeyUp()))),this._register(r.ko(this._actual,s.Tap,(()=>this._onSyntheticTap.fire())))}hasFocus(){const e=r.jG(this._actual);return e?e.activeElement===this._actual:!!this._actual.isConnected&&r.bq()===this._actual}setIgnoreSelectionChangeTime(e){this._ignoreSelectionChangeTime=Date.now()}getIgnoreSelectionChangeTime(){return this._ignoreSelectionChangeTime}resetSelectionChangeTime(){this._ignoreSelectionChangeTime=0}getValue(){return this._actual.value}setValue(e,t){const i=this._actual;i.value!==t&&(this.setIgnoreSelectionChangeTime("setValue"),i.value=t)}getSelectionStart(){return"backward"===this._actual.selectionDirection?this._actual.selectionEnd:this._actual.selectionStart}getSelectionEnd(){return"backward"===this._actual.selectionDirection?this._actual.selectionStart:this._actual.selectionEnd}setSelectionRange(e,t,i){const s=this._actual;let o=null;const a=r.jG(s);o=a?a.activeElement:r.bq();const c=r.zk(o),l=o===s,h=s.selectionStart,d=s.selectionEnd;if(l&&h===t&&d===i)n.gm&&c.parent!==c&&s.focus();else{if(l)return this.setIgnoreSelectionChangeTime("setSelectionRange"),s.setSelectionRange(t,i),void(n.gm&&c.parent!==c&&s.focus());try{const e=r.zK(s);this.setIgnoreSelectionChangeTime("setSelectionRange"),s.focus(),s.setSelectionRange(t,i),r.wk(s,e)}catch(u){}}}}},68887:(e,t,i)=>{"use strict";var s=i(90766),n=i(10350),r=i(16980),o=i(5662),a=i(98067),c=i(91508),l=i(31450),h=i(87908),d=i(87289),u=i(74855),g=i(10920),p=i(10154),m=i(32398),f=i(57039),_=i(57286),v=i(8597),C=i(11799),E=i(36921),b=i(20492),S=i(63591),y=i(56245),w=i(72962),R=i(25154),L=i(41234),T=i(49099),x=i(42904),k=i(67220),A=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},N=function(e,t){return function(i,s){t(i,s,e)}};let I=class extends o.jG{get enabled(){return this._enabled}set enabled(e){e?(this.el.setAttribute("aria-disabled","false"),this.el.tabIndex=0,this.el.style.pointerEvents="auto",this.el.style.opacity="1",this.el.style.cursor="pointer",this._enabled=!1):(this.el.setAttribute("aria-disabled","true"),this.el.tabIndex=-1,this.el.style.pointerEvents="none",this.el.style.opacity="0.4",this.el.style.cursor="default",this._enabled=!0),this._enabled=e}constructor(e,t,i={},s,n){super(),this._link=t,this._hoverService=s,this._enabled=!0,this.el=(0,v.BC)(e,(0,v.$)("a.monaco-link",{tabIndex:t.tabIndex??0,href:t.href},t.label)),this.hoverDelegate=i.hoverDelegate??(0,x.nZ)("mouse"),this.setTooltip(t.title),this.el.setAttribute("role","button");const r=this._register(new y.f(this.el,"click")),o=this._register(new y.f(this.el,"keypress")),a=L.Jh.chain(o.event,(e=>e.map((e=>new w.Z(e))).filter((e=>3===e.keyCode)))),c=this._register(new y.f(this.el,R.B.Tap)).event;this._register(R.q.addTarget(this.el));const l=L.Jh.any(r.event,a,c);this._register(l((e=>{this.enabled&&(v.fs.stop(e,!0),i?.opener?i.opener(this._link.href):n.open(this._link.href,{allowCommands:!0}))}))),this.enabled=!0}setTooltip(e){this.hoverDelegate.showNativeHover?this.el.title=e??"":!this.hover&&e?this.hover=this._register(this._hoverService.setupManagedHover(this.hoverDelegate,this.el,e)):this.hover&&this.hover.update(e)}};I=A([N(3,k.TN),N(4,T.C)],I);var O=i(61394),D=i(25689),M=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},P=function(e,t){return function(i,s){t(i,s,e)}};let F=class extends o.jG{constructor(e,t){super(),this._editor=e,this.instantiationService=t,this.banner=this._register(this.instantiationService.createInstance(U))}hide(){this._editor.setBanner(null,0),this.banner.clear()}show(e){this.banner.show({...e,onClose:()=>{this.hide(),e.onClose?.()}}),this._editor.setBanner(this.banner.element,26)}};F=M([P(1,S._Y)],F);let U=class extends o.jG{constructor(e){super(),this.instantiationService=e,this.markdownRenderer=this.instantiationService.createInstance(b.T,{}),this.element=(0,v.$)("div.editor-banner"),this.element.tabIndex=0}getAriaLabel(e){return e.ariaLabel?e.ariaLabel:"string"===typeof e.message?e.message:void 0}getBannerMessage(e){if("string"===typeof e){const t=(0,v.$)("span");return t.innerText=e,t}return this.markdownRenderer.render(e).element}clear(){(0,v.w_)(this.element)}show(e){(0,v.w_)(this.element);const t=this.getAriaLabel(e);t&&this.element.setAttribute("aria-label",t);const i=(0,v.BC)(this.element,(0,v.$)("div.icon-container"));i.setAttribute("aria-hidden","true"),e.icon&&i.appendChild((0,v.$)(`div${D.L.asCSSSelector(e.icon)}`));const s=(0,v.BC)(this.element,(0,v.$)("div.message-container"));if(s.setAttribute("aria-hidden","true"),s.appendChild(this.getBannerMessage(e.message)),this.messageActionsContainer=(0,v.BC)(this.element,(0,v.$)("div.message-actions-container")),e.actions)for(const r of e.actions)this._register(this.instantiationService.createInstance(I,this.messageActionsContainer,{...r,tabIndex:-1},{}));const n=(0,v.BC)(this.element,(0,v.$)("div.action-container"));this.actionBar=this._register(new C.E(n)),this.actionBar.push(this._register(new E.rc("banner.close","Close Banner",D.L.asClassName(O.$_),!0,(()=>{"function"===typeof e.onClose&&e.onClose()}))),{icon:!0,label:!1}),this.actionBar.setFocusable(!1)}};U=M([P(0,S._Y)],U);var H=i(78209),B=i(84001),W=i(51467),V=i(51465),z=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},G=function(e,t){return function(i,s){t(i,s,e)}};const j=(0,O.pU)("extensions-warning-message",n.W.warning,H.kg("warningIcon","Icon shown with a warning message in the extensions editor."));let K=class extends o.jG{static{this.ID="editor.contrib.unicodeHighlighter"}constructor(e,t,i,s){super(),this._editor=e,this._editorWorkerService=t,this._workspaceTrustService=i,this._highlighter=null,this._bannerClosed=!1,this._updateState=e=>{if(e&&e.hasMore){if(this._bannerClosed)return;const t=Math.max(e.ambiguousCharacterCount,e.nonBasicAsciiCharacterCount,e.invisibleCharacterCount);let i;if(e.nonBasicAsciiCharacterCount>=t)i={message:H.kg("unicodeHighlighting.thisDocumentHasManyNonBasicAsciiUnicodeCharacters","This document contains many non-basic ASCII unicode characters"),command:new re};else if(e.ambiguousCharacterCount>=t)i={message:H.kg("unicodeHighlighting.thisDocumentHasManyAmbiguousUnicodeCharacters","This document contains many ambiguous unicode characters"),command:new se};else{if(!(e.invisibleCharacterCount>=t))throw new Error("Unreachable");i={message:H.kg("unicodeHighlighting.thisDocumentHasManyInvisibleUnicodeCharacters","This document contains many invisible unicode characters"),command:new ne}}this._bannerController.show({id:"unicodeHighlightBanner",message:i.message,icon:j,actions:[{label:i.command.shortLabel,href:`command:${i.command.id}`}],onClose:()=>{this._bannerClosed=!0}})}else this._bannerController.hide()},this._bannerController=this._register(s.createInstance(F,e)),this._register(this._editor.onDidChangeModel((()=>{this._bannerClosed=!1,this._updateHighlighter()}))),this._options=e.getOption(126),this._register(i.onDidChangeTrust((e=>{this._updateHighlighter()}))),this._register(e.onDidChangeConfiguration((t=>{t.hasChanged(126)&&(this._options=e.getOption(126),this._updateHighlighter())}))),this._updateHighlighter()}dispose(){this._highlighter&&(this._highlighter.dispose(),this._highlighter=null),super.dispose()}_updateHighlighter(){if(this._updateState(null),this._highlighter&&(this._highlighter.dispose(),this._highlighter=null),!this._editor.hasModel())return;const e=function(e,t){return{nonBasicASCII:t.nonBasicASCII===h.XR?!e:t.nonBasicASCII,ambiguousCharacters:t.ambiguousCharacters,invisibleCharacters:t.invisibleCharacters,includeComments:t.includeComments===h.XR?!e:t.includeComments,includeStrings:t.includeStrings===h.XR?!e:t.includeStrings,allowedCharacters:t.allowedCharacters,allowedLocales:t.allowedLocales}}(this._workspaceTrustService.isWorkspaceTrusted(),this._options);if([e.nonBasicASCII,e.ambiguousCharacters,e.invisibleCharacters].every((e=>!1===e)))return;const t={nonBasicASCII:e.nonBasicASCII,ambiguousCharacters:e.ambiguousCharacters,invisibleCharacters:e.invisibleCharacters,includeComments:e.includeComments,includeStrings:e.includeStrings,allowedCodePoints:Object.keys(e.allowedCharacters).map((e=>e.codePointAt(0))),allowedLocales:Object.keys(e.allowedLocales).map((e=>{if("_os"===e){return(new Intl.NumberFormat).resolvedOptions().locale}return"_vscode"===e?a.BH:e}))};this._editorWorkerService.canComputeUnicodeHighlights(this._editor.getModel().uri)?this._highlighter=new Y(this._editor,t,this._updateState,this._editorWorkerService):this._highlighter=new q(this._editor,t,this._updateState)}getDecorationInfo(e){return this._highlighter?this._highlighter.getDecorationInfo(e):null}};K=z([G(1,g.IEditorWorkerService),G(2,V.L),G(3,S._Y)],K);let Y=class extends o.jG{constructor(e,t,i,n){super(),this._editor=e,this._options=t,this._updateState=i,this._editorWorkerService=n,this._model=this._editor.getModel(),this._decorations=this._editor.createDecorationsCollection(),this._updateSoon=this._register(new s.uC((()=>this._update()),250)),this._register(this._editor.onDidChangeModelContent((()=>{this._updateSoon.schedule()}))),this._updateSoon.schedule()}dispose(){this._decorations.clear(),super.dispose()}_update(){if(this._model.isDisposed())return;if(!this._model.mightContainNonBasicASCII())return void this._decorations.clear();const e=this._model.getVersionId();this._editorWorkerService.computedUnicodeHighlights(this._model.uri,this._options).then((t=>{if(this._model.isDisposed())return;if(this._model.getVersionId()!==e)return;this._updateState(t);const i=[];if(!t.hasMore)for(const e of t.ranges)i.push({range:e,options:ee.instance.getDecorationFromOptions(this._options)});this._decorations.set(i)}))}getDecorationInfo(e){if(!this._decorations.has(e))return null;const t=this._editor.getModel();if(!(0,m.GN)(t,e))return null;return{reason:J(t.getValueInRange(e.range),this._options),inComment:(0,m.a6)(t,e),inString:(0,m.wc)(t,e)}}};Y=z([G(3,g.IEditorWorkerService)],Y);class q extends o.jG{constructor(e,t,i){super(),this._editor=e,this._options=t,this._updateState=i,this._model=this._editor.getModel(),this._decorations=this._editor.createDecorationsCollection(),this._updateSoon=this._register(new s.uC((()=>this._update()),250)),this._register(this._editor.onDidLayoutChange((()=>{this._updateSoon.schedule()}))),this._register(this._editor.onDidScrollChange((()=>{this._updateSoon.schedule()}))),this._register(this._editor.onDidChangeHiddenAreas((()=>{this._updateSoon.schedule()}))),this._register(this._editor.onDidChangeModelContent((()=>{this._updateSoon.schedule()}))),this._updateSoon.schedule()}dispose(){this._decorations.clear(),super.dispose()}_update(){if(this._model.isDisposed())return;if(!this._model.mightContainNonBasicASCII())return void this._decorations.clear();const e=this._editor.getVisibleRanges(),t=[],i={ranges:[],ambiguousCharacterCount:0,invisibleCharacterCount:0,nonBasicAsciiCharacterCount:0,hasMore:!1};for(const s of e){const e=u.UnicodeTextModelHighlighter.computeUnicodeHighlights(this._model,this._options,s);for(const t of e.ranges)i.ranges.push(t);i.ambiguousCharacterCount+=i.ambiguousCharacterCount,i.invisibleCharacterCount+=i.invisibleCharacterCount,i.nonBasicAsciiCharacterCount+=i.nonBasicAsciiCharacterCount,i.hasMore=i.hasMore||e.hasMore}if(!i.hasMore)for(const s of i.ranges)t.push({range:s,options:ee.instance.getDecorationFromOptions(this._options)});this._updateState(i),this._decorations.set(t)}getDecorationInfo(e){if(!this._decorations.has(e))return null;const t=this._editor.getModel(),i=t.getValueInRange(e.range);return(0,m.GN)(t,e)?{reason:J(i,this._options),inComment:(0,m.a6)(t,e),inString:(0,m.wc)(t,e)}:null}}const $=H.kg("unicodeHighlight.configureUnicodeHighlightOptions","Configure Unicode Highlight Options");let Q=class{constructor(e,t,i){this._editor=e,this._languageService=t,this._openerService=i,this.hoverOrdinal=5}computeSync(e,t){if(!this._editor.hasModel()||1!==e.type)return[];const i=this._editor.getModel(),s=this._editor.getContribution(K.ID);if(!s)return[];const n=[],o=new Set;let a=300;for(const l of t){const e=s.getDecorationInfo(l);if(!e)continue;const t=i.getValueInRange(l.range).codePointAt(0),h=Z(t);let d;switch(e.reason.kind){case 0:d=(0,c.aC)(e.reason.confusableWith)?H.kg("unicodeHighlight.characterIsAmbiguousASCII","The character {0} could be confused with the ASCII character {1}, which is more common in source code.",h,Z(e.reason.confusableWith.codePointAt(0))):H.kg("unicodeHighlight.characterIsAmbiguous","The character {0} could be confused with the character {1}, which is more common in source code.",h,Z(e.reason.confusableWith.codePointAt(0)));break;case 1:d=H.kg("unicodeHighlight.characterIsInvisible","The character {0} is invisible.",h);break;case 2:d=H.kg("unicodeHighlight.characterIsNonBasicAscii","The character {0} is not a basic ASCII character.",h)}if(o.has(d))continue;o.add(d);const u={codePoint:t,reason:e.reason,inComment:e.inComment,inString:e.inString},g=H.kg("unicodeHighlight.adjustSettings","Adjust settings"),p=`command:${oe.ID}?${encodeURIComponent(JSON.stringify(u))}`,m=new r.Bc("",!0).appendMarkdown(d).appendText(" ").appendLink(p,g,$);n.push(new _.eH(this,l.range,[m],!1,a++))}return n}renderHoverParts(e,t){return(0,_.fm)(e,t,this._editor,this._languageService,this._openerService)}};function X(e){return`U+${e.toString(16).padStart(4,"0")}`}function Z(e){let t=`\`${X(e)}\``;return c.y_.isInvisibleCharacter(e)||(t+=` "${function(e){if(96===e)return"`` ` ``";return"`"+String.fromCodePoint(e)+"`"}(e)}"`),t}function J(e,t){return u.UnicodeTextModelHighlighter.computeUnicodeHighlightReason(e,t)}Q=z([G(1,p.L),G(2,T.C)],Q);class ee{constructor(){this.map=new Map}static{this.instance=new ee}getDecorationFromOptions(e){return this.getDecoration(!e.includeComments,!e.includeStrings)}getDecoration(e,t){const i=`${e}${t}`;let s=this.map.get(i);return s||(s=d.kI.createDynamic({description:"unicode-highlight",stickiness:1,className:"unicode-highlight",showIfCollapsed:!0,overviewRuler:null,minimap:null,hideInCommentTokens:e,hideInStringTokens:t}),this.map.set(i,s)),s}}class te extends l.ks{constructor(){super({id:se.ID,label:H.kg("action.unicodeHighlight.disableHighlightingInComments","Disable highlighting of characters in comments"),alias:"Disable highlighting of characters in comments",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingInComments.shortLabel","Disable Highlight In Comments")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.includeComments,!1,2)}}class ie extends l.ks{constructor(){super({id:se.ID,label:H.kg("action.unicodeHighlight.disableHighlightingInStrings","Disable highlighting of characters in strings"),alias:"Disable highlighting of characters in strings",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingInStrings.shortLabel","Disable Highlight In Strings")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.includeStrings,!1,2)}}class se extends l.ks{static{this.ID="editor.action.unicodeHighlight.disableHighlightingOfAmbiguousCharacters"}constructor(){super({id:se.ID,label:H.kg("action.unicodeHighlight.disableHighlightingOfAmbiguousCharacters","Disable highlighting of ambiguous characters"),alias:"Disable highlighting of ambiguous characters",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingOfAmbiguousCharacters.shortLabel","Disable Ambiguous Highlight")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.ambiguousCharacters,!1,2)}}class ne extends l.ks{static{this.ID="editor.action.unicodeHighlight.disableHighlightingOfInvisibleCharacters"}constructor(){super({id:ne.ID,label:H.kg("action.unicodeHighlight.disableHighlightingOfInvisibleCharacters","Disable highlighting of invisible characters"),alias:"Disable highlighting of invisible characters",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingOfInvisibleCharacters.shortLabel","Disable Invisible Highlight")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.invisibleCharacters,!1,2)}}class re extends l.ks{static{this.ID="editor.action.unicodeHighlight.disableHighlightingOfNonBasicAsciiCharacters"}constructor(){super({id:re.ID,label:H.kg("action.unicodeHighlight.disableHighlightingOfNonBasicAsciiCharacters","Disable highlighting of non basic ASCII characters"),alias:"Disable highlighting of non basic ASCII characters",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingOfNonBasicAsciiCharacters.shortLabel","Disable Non ASCII Highlight")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.nonBasicASCII,!1,2)}}class oe extends l.ks{static{this.ID="editor.action.unicodeHighlight.showExcludeOptions"}constructor(){super({id:oe.ID,label:H.kg("action.unicodeHighlight.showExcludeOptions","Show Exclude Options"),alias:"Show Exclude Options",precondition:void 0})}async run(e,t,i){const{codePoint:s,reason:n,inString:r,inComment:o}=i,a=String.fromCodePoint(s),l=e.get(W.GK),d=e.get(B.pG);const u=[];if(0===n.kind)for(const c of n.notAmbiguousInLocales)u.push({label:H.kg("unicodeHighlight.allowCommonCharactersInLanguage",'Allow unicode characters that are more common in the language "{0}".',c),run:async()=>{ae(d,[c])}});if(u.push({label:function(e){return c.y_.isInvisibleCharacter(e)?H.kg("unicodeHighlight.excludeInvisibleCharFromBeingHighlighted","Exclude {0} (invisible character) from being highlighted",X(e)):H.kg("unicodeHighlight.excludeCharFromBeingHighlighted","Exclude {0} from being highlighted",`${X(e)} "${a}"`)}(s),run:()=>async function(e,t){const i=e.getValue(h.Of.allowedCharacters);let s;s="object"===typeof i&&i?i:{};for(const n of t)s[String.fromCodePoint(n)]=!0;await e.updateValue(h.Of.allowedCharacters,s,2)}(d,[s])}),o){const e=new te;u.push({label:e.label,run:async()=>e.runAction(d)})}else if(r){const e=new ie;u.push({label:e.label,run:async()=>e.runAction(d)})}if(0===n.kind){const e=new se;u.push({label:e.label,run:async()=>e.runAction(d)})}else if(1===n.kind){const e=new ne;u.push({label:e.label,run:async()=>e.runAction(d)})}else if(2===n.kind){const e=new re;u.push({label:e.label,run:async()=>e.runAction(d)})}else!function(e){throw new Error(`Unexpected value: ${e}`)}(n);const g=await l.pick(u,{title:$});g&&await g.run()}}async function ae(e,t){const i=e.inspect(h.Of.allowedLocales).user?.value;let s;s="object"===typeof i&&i?Object.assign({},i):{};for(const n of t)s[n]=!0;await e.updateValue(h.Of.allowedLocales,s,2)}(0,l.Fl)(se),(0,l.Fl)(ne),(0,l.Fl)(re),(0,l.Fl)(oe),(0,l.HW)(K.ID,K,1),f.B2.register(Q)},68938:(e,t,i)=>{"use strict";i.d(t,{$8:()=>a,SL:()=>o,_3:()=>c,aY:()=>h,uY:()=>l});var s=i(25890),n=i(64383),r=i(74444);class o{static trivial(e,t){return new o([new a(r.L.ofLength(e.length),r.L.ofLength(t.length))],!1)}static trivialTimedOut(e,t){return new o([new a(r.L.ofLength(e.length),r.L.ofLength(t.length))],!0)}constructor(e,t){this.diffs=e,this.hitTimeout=t}}class a{static invert(e,t){const i=[];return(0,s.pN)(e,((e,s)=>{i.push(a.fromOffsetPairs(e?e.getEndExclusives():c.zero,s?s.getStarts():new c(t,(e?e.seq2Range.endExclusive-e.seq1Range.endExclusive:0)+t)))})),i}static fromOffsetPairs(e,t){return new a(new r.L(e.offset1,t.offset1),new r.L(e.offset2,t.offset2))}static assertSorted(e){let t;for(const i of e){if(t&&!(t.seq1Range.endExclusive<=i.seq1Range.start&&t.seq2Range.endExclusive<=i.seq2Range.start))throw new n.D7("Sequence diffs must be sorted");t=i}}constructor(e,t){this.seq1Range=e,this.seq2Range=t}swap(){return new a(this.seq2Range,this.seq1Range)}toString(){return`${this.seq1Range} <-> ${this.seq2Range}`}join(e){return new a(this.seq1Range.join(e.seq1Range),this.seq2Range.join(e.seq2Range))}delta(e){return 0===e?this:new a(this.seq1Range.delta(e),this.seq2Range.delta(e))}deltaStart(e){return 0===e?this:new a(this.seq1Range.deltaStart(e),this.seq2Range.deltaStart(e))}deltaEnd(e){return 0===e?this:new a(this.seq1Range.deltaEnd(e),this.seq2Range.deltaEnd(e))}intersect(e){const t=this.seq1Range.intersect(e.seq1Range),i=this.seq2Range.intersect(e.seq2Range);if(t&&i)return new a(t,i)}getStarts(){return new c(this.seq1Range.start,this.seq2Range.start)}getEndExclusives(){return new c(this.seq1Range.endExclusive,this.seq2Range.endExclusive)}}class c{static{this.zero=new c(0,0)}static{this.max=new c(Number.MAX_SAFE_INTEGER,Number.MAX_SAFE_INTEGER)}constructor(e,t){this.offset1=e,this.offset2=t}toString(){return`${this.offset1} <-> ${this.offset2}`}delta(e){return 0===e?this:new c(this.offset1+e,this.offset2+e)}equals(e){return this.offset1===e.offset1&&this.offset2===e.offset2}}class l{static{this.instance=new l}isValid(){return!0}}class h{constructor(e){if(this.timeout=e,this.startTime=Date.now(),this.valid=!0,e<=0)throw new n.D7("timeout must be positive")}isValid(){return!(Date.now()-this.startTime{"use strict";i.r(t),i.d(t,{LanguageIdCodec:()=>u,LanguagesRegistry:()=>g});var s=i(41234),n=i(5662),r=i(91508),o=i(99908),a=i(83941),c=i(1646),l=i(46359);const h=Object.prototype.hasOwnProperty,d="vs.editor.nullLanguage";class u{constructor(){this._languageIdToLanguage=[],this._languageToLanguageId=new Map,this._register(d,0),this._register(a.vH,1),this._nextLanguageId=2}_register(e,t){this._languageIdToLanguage[t]=e,this._languageToLanguageId.set(e,t)}register(e){if(this._languageToLanguageId.has(e))return;const t=this._nextLanguageId++;this._register(e,t)}encodeLanguageId(e){return this._languageToLanguageId.get(e)||0}decodeLanguageId(e){return this._languageIdToLanguage[e]||d}}class g extends n.jG{static{this.instanceCount=0}constructor(e=!0,t=!1){super(),this._onDidChange=this._register(new s.vl),this.onDidChange=this._onDidChange.event,g.instanceCount++,this._warnOnOverwrite=t,this.languageIdCodec=new u,this._dynamicLanguages=[],this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},e&&(this._initializeFromRegistry(),this._register(a.W6.onDidChangeLanguages((e=>{this._initializeFromRegistry()}))))}dispose(){g.instanceCount--,super.dispose()}_initializeFromRegistry(){this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},(0,o.clearPlatformLanguageAssociations)();const e=[].concat(a.W6.getLanguages()).concat(this._dynamicLanguages);this._registerLanguages(e)}_registerLanguages(e){for(const t of e)this._registerLanguage(t);this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},Object.keys(this._languages).forEach((e=>{const t=this._languages[e];t.name&&(this._nameMap[t.name]=t.identifier),t.aliases.forEach((e=>{this._lowercaseNameMap[e.toLowerCase()]=t.identifier})),t.mimetypes.forEach((e=>{this._mimeTypesMap[e]=t.identifier}))})),l.O.as(c.Fd.Configuration).registerOverrideIdentifiers(this.getRegisteredLanguageIds()),this._onDidChange.fire()}_registerLanguage(e){const t=e.id;let i;h.call(this._languages,t)?i=this._languages[t]:(this.languageIdCodec.register(t),i={identifier:t,name:null,mimetypes:[],aliases:[],extensions:[],filenames:[],configurationFiles:[],icons:[]},this._languages[t]=i),this._mergeLanguage(i,e)}_mergeLanguage(e,t){const i=t.id;let s=null;if(Array.isArray(t.mimetypes)&&t.mimetypes.length>0&&(e.mimetypes.push(...t.mimetypes),s=t.mimetypes[0]),s||(s=`text/x-${i}`,e.mimetypes.push(s)),Array.isArray(t.extensions)){t.configuration?e.extensions=t.extensions.concat(e.extensions):e.extensions=e.extensions.concat(t.extensions);for(const e of t.extensions)(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,extension:e},this._warnOnOverwrite)}if(Array.isArray(t.filenames))for(const r of t.filenames)(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,filename:r},this._warnOnOverwrite),e.filenames.push(r);if(Array.isArray(t.filenamePatterns))for(const r of t.filenamePatterns)(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,filepattern:r},this._warnOnOverwrite);if("string"===typeof t.firstLine&&t.firstLine.length>0){let e=t.firstLine;"^"!==e.charAt(0)&&(e="^"+e);try{const t=new RegExp(e);(0,r.eY)(t)||(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,firstline:t},this._warnOnOverwrite)}catch(c){console.warn(`[${t.id}]: Invalid regular expression \`${e}\`: `,c)}}e.aliases.push(i);let n=null;if("undefined"!==typeof t.aliases&&Array.isArray(t.aliases)&&(n=0===t.aliases.length?[null]:t.aliases),null!==n)for(const r of n)r&&0!==r.length&&e.aliases.push(r);const a=null!==n&&n.length>0;if(a&&null===n[0]);else{const t=(a?n[0]:null)||i;!a&&e.name||(e.name=t)}t.configuration&&e.configurationFiles.push(t.configuration),t.icon&&e.icons.push(t.icon)}isRegisteredLanguageId(e){return!!e&&h.call(this._languages,e)}getRegisteredLanguageIds(){return Object.keys(this._languages)}getLanguageIdByLanguageName(e){const t=e.toLowerCase();return h.call(this._lowercaseNameMap,t)?this._lowercaseNameMap[t]:null}getLanguageIdByMimeType(e){return e&&h.call(this._mimeTypesMap,e)?this._mimeTypesMap[e]:null}guessLanguageIdByFilepathOrFirstLine(e,t){return e||t?(0,o.getLanguageIds)(e,t):[]}}},69418:(e,t,i)=>{"use strict";i.d(t,{C:()=>n,o:()=>r});var s=i(82435);const n="g-date-",r=(0,s.withNaming)({n:n,e:"__",m:"_"})},69785:(e,t,i)=>{"use strict";i.d(t,{Al:()=>a,Hf:()=>r,_O:()=>o});var s=i(91508),n=i(36677);const r=!1;class o{static{this.EMPTY=new o("",0,0,null,void 0)}constructor(e,t,i,s,n){this.value=e,this.selectionStart=t,this.selectionEnd=i,this.selection=s,this.newlineCountBeforeSelection=n}toString(){return`[ <${this.value}>, selectionStart: ${this.selectionStart}, selectionEnd: ${this.selectionEnd}]`}static readFromTextArea(e,t){const i=e.getValue(),s=e.getSelectionStart(),n=e.getSelectionEnd();let r;if(t){i.substring(0,s)===t.value.substring(0,t.selectionStart)&&(r=t.newlineCountBeforeSelection)}return new o(i,s,n,null,r)}collapseSelection(){return this.selectionStart===this.value.length?this:new o(this.value,this.value.length,this.value.length,null,void 0)}writeToTextArea(e,t,i){r&&console.log(`writeToTextArea ${e}: ${this.toString()}`),t.setValue(e,this.value),i&&t.setSelectionRange(e,this.selectionStart,this.selectionEnd)}deduceEditorPosition(e){if(e<=this.selectionStart){const t=this.value.substring(e,this.selectionStart);return this._finishDeduceEditorPosition(this.selection?.getStartPosition()??null,t,-1)}if(e>=this.selectionEnd){const t=this.value.substring(this.selectionEnd,e);return this._finishDeduceEditorPosition(this.selection?.getEndPosition()??null,t,1)}const t=this.value.substring(this.selectionStart,e);if(-1===t.indexOf(String.fromCharCode(8230)))return this._finishDeduceEditorPosition(this.selection?.getStartPosition()??null,t,1);const i=this.value.substring(e,this.selectionEnd);return this._finishDeduceEditorPosition(this.selection?.getEndPosition()??null,i,-1)}_finishDeduceEditorPosition(e,t,i){let s=0,n=-1;for(;-1!==(n=t.indexOf("\n",n+1));)s++;return[e,i*t.length,s]}static deduceInput(e,t,i){if(!e)return{text:"",replacePrevCharCnt:0,replaceNextCharCnt:0,positionDelta:0};r&&(console.log("------------------------deduceInput"),console.log(`PREVIOUS STATE: ${e.toString()}`),console.log(`CURRENT STATE: ${t.toString()}`));const n=Math.min(s.Qp(e.value,t.value),e.selectionStart,t.selectionStart),o=Math.min(s.Vi(e.value,t.value),e.value.length-e.selectionEnd,t.value.length-t.selectionEnd),a=e.value.substring(n,e.value.length-o),c=t.value.substring(n,t.value.length-o),l=e.selectionStart-n,h=e.selectionEnd-n,d=t.selectionStart-n,u=t.selectionEnd-n;if(r&&(console.log(`AFTER DIFFING PREVIOUS STATE: <${a}>, selectionStart: ${l}, selectionEnd: ${h}`),console.log(`AFTER DIFFING CURRENT STATE: <${c}>, selectionStart: ${d}, selectionEnd: ${u}`)),d===u){const t=e.selectionStart-n;return r&&console.log(`REMOVE PREVIOUS: ${t} chars`),{text:c,replacePrevCharCnt:t,replaceNextCharCnt:0,positionDelta:0}}return{text:c,replacePrevCharCnt:h-l,replaceNextCharCnt:0,positionDelta:0}}static deduceAndroidCompositionInput(e,t){if(!e)return{text:"",replacePrevCharCnt:0,replaceNextCharCnt:0,positionDelta:0};if(r&&(console.log("------------------------deduceAndroidCompositionInput"),console.log(`PREVIOUS STATE: ${e.toString()}`),console.log(`CURRENT STATE: ${t.toString()}`)),e.value===t.value)return{text:"",replacePrevCharCnt:0,replaceNextCharCnt:0,positionDelta:t.selectionEnd-e.selectionEnd};const i=Math.min(s.Qp(e.value,t.value),e.selectionEnd),n=Math.min(s.Vi(e.value,t.value),e.value.length-e.selectionEnd),o=e.value.substring(i,e.value.length-n),a=t.value.substring(i,t.value.length-n),c=e.selectionStart-i,l=e.selectionEnd-i,h=t.selectionStart-i,d=t.selectionEnd-i;return r&&(console.log(`AFTER DIFFING PREVIOUS STATE: <${o}>, selectionStart: ${c}, selectionEnd: ${l}`),console.log(`AFTER DIFFING CURRENT STATE: <${a}>, selectionStart: ${h}, selectionEnd: ${d}`)),{text:a,replacePrevCharCnt:l,replaceNextCharCnt:o.length-l,positionDelta:d-a.length}}}class a{static _getPageOfLine(e,t){return Math.floor((e-1)/t)}static _getRangeForPage(e,t){const i=e*t,s=i+1,r=i+t;return new n.Q(s,1,r+1,1)}static fromEditorSelection(e,t,i,s){const r=500,c=a._getPageOfLine(t.startLineNumber,i),l=a._getRangeForPage(c,i),h=a._getPageOfLine(t.endLineNumber,i),d=a._getRangeForPage(h,i);let u=l.intersectRanges(new n.Q(1,1,t.startLineNumber,t.startColumn));if(s&&e.getValueLengthInRange(u,1)>r){const t=e.modifyPosition(u.getEndPosition(),-500);u=n.Q.fromPositions(t,u.getEndPosition())}const g=e.getValueInRange(u,1),p=e.getLineCount(),m=e.getLineMaxColumn(p);let f=d.intersectRanges(new n.Q(t.endLineNumber,t.endColumn,p,m));if(s&&e.getValueLengthInRange(f,1)>r){const t=e.modifyPosition(f.getStartPosition(),r);f=n.Q.fromPositions(f.getStartPosition(),t)}const _=e.getValueInRange(f,1);let v;if(c===h||c+1===h)v=e.getValueInRange(t,1);else{const i=l.intersectRanges(t),s=d.intersectRanges(t);v=e.getValueInRange(i,1)+String.fromCharCode(8230)+e.getValueInRange(s,1)}return s&&v.length>1e3&&(v=v.substring(0,r)+String.fromCharCode(8230)+v.substring(v.length-r,v.length)),new o(g+v+_,g.length,g.length+v.length,t,u.endLineNumber-u.startLineNumber)}}},70125:(e,t,i)=>{"use strict";i.d(t,{r:()=>l});var s=i(25890),n=i(631),r=i(78209);function o(e,t){return t&&(e.stack||e.stacktrace)?r.kg("stackTrace.format","{0}: {1}",c(e),a(e.stack)||a(e.stacktrace)):c(e)}function a(e){return Array.isArray(e)?e.join("\n"):e}function c(e){return"ERR_UNC_HOST_NOT_ALLOWED"===e.code?`${e.message}. Please update the 'security.allowedUNCHosts' setting if you want to allow this host.`:"string"===typeof e.code&&"number"===typeof e.errno&&"string"===typeof e.syscall?r.kg("nodeExceptionMessage","A system error occurred ({0})",e.message):e.message||r.kg("error.defaultMessage","An unknown error occurred. Please consult the log for more details.")}function l(e=null,t=!1){if(!e)return r.kg("error.defaultMessage","An unknown error occurred. Please consult the log for more details.");if(Array.isArray(e)){const i=s.Yc(e),n=l(i[0],t);return i.length>1?r.kg("error.moreErrors","{0} ({1} errors in total)",n,i.length):n}if(n.Kg(e))return e;if(e.detail){const i=e.detail;if(i.error)return o(i.error,t);if(i.exception)return o(i.exception,t)}return e.stack?o(e,t):e.message?e.message:r.kg("error.defaultMessage","An unknown error occurred. Please consult the log for more details.")}},70206:(e,t)=>{var i;i=function(e){e.version="1.2.2";var t=function(){for(var e=0,t=new Array(256),i=0;256!=i;++i)e=1&(e=1&(e=1&(e=1&(e=1&(e=1&(e=1&(e=1&(e=i)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1,t[i]=e;return"undefined"!==typeof Int32Array?new Int32Array(t):t}(),i=function(e){var t=0,i=0,s=0,n="undefined"!==typeof Int32Array?new Int32Array(4096):new Array(4096);for(s=0;256!=s;++s)n[s]=e[s];for(s=0;256!=s;++s)for(i=e[s],t=256+s;t<4096;t+=256)i=n[t]=i>>>8^e[255&i];var r=[];for(s=1;16!=s;++s)r[s-1]="undefined"!==typeof Int32Array?n.subarray(256*s,256*s+256):n.slice(256*s,256*s+256);return r}(t),s=i[0],n=i[1],r=i[2],o=i[3],a=i[4],c=i[5],l=i[6],h=i[7],d=i[8],u=i[9],g=i[10],p=i[11],m=i[12],f=i[13],_=i[14];e.table=t,e.bstr=function(e,i){for(var s=~i,n=0,r=e.length;n>>8^t[255&(s^e.charCodeAt(n++))];return~s},e.buf=function(e,i){for(var v=~i,C=e.length-15,E=0;E>8&255]^m[e[E++]^v>>16&255]^p[e[E++]^v>>>24]^g[e[E++]]^u[e[E++]]^d[e[E++]]^h[e[E++]]^l[e[E++]]^c[e[E++]]^a[e[E++]]^o[e[E++]]^r[e[E++]]^n[e[E++]]^s[e[E++]]^t[e[E++]];for(C+=15;E>>8^t[255&(v^e[E++])];return~v},e.str=function(e,i){for(var s=~i,n=0,r=e.length,o=0,a=0;n>>8^t[255&(s^o)]:o<2048?s=(s=s>>>8^t[255&(s^(192|o>>6&31))])>>>8^t[255&(s^(128|63&o))]:o>=55296&&o<57344?(o=64+(1023&o),a=1023&e.charCodeAt(n++),s=(s=(s=(s=s>>>8^t[255&(s^(240|o>>8&7))])>>>8^t[255&(s^(128|o>>2&63))])>>>8^t[255&(s^(128|a>>6&15|(3&o)<<4))])>>>8^t[255&(s^(128|63&a))]):s=(s=(s=s>>>8^t[255&(s^(224|o>>12&15))])>>>8^t[255&(s^(128|o>>6&63))])>>>8^t[255&(s^(128|63&o))];return~s}},"undefined"===typeof DO_NOT_EXPORT_CRC?i(t):i({})},70492:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"razor",extensions:[".cshtml"],aliases:["Razor","razor"],mimetypes:["text/x-cshtml"],loader:()=>i.e(58986).then(i.bind(i,58986))})},70552:(e,t,i)=>{"use strict";var s=i(31450),n=i(79027),r=i(78209);class o extends s.ks{constructor(){super({id:"editor.action.fontZoomIn",label:r.kg("EditorFontZoomIn.label","Increase Editor Font Size"),alias:"Increase Editor Font Size",precondition:void 0})}run(e,t){n.D.setZoomLevel(n.D.getZoomLevel()+1)}}class a extends s.ks{constructor(){super({id:"editor.action.fontZoomOut",label:r.kg("EditorFontZoomOut.label","Decrease Editor Font Size"),alias:"Decrease Editor Font Size",precondition:void 0})}run(e,t){n.D.setZoomLevel(n.D.getZoomLevel()-1)}}class c extends s.ks{constructor(){super({id:"editor.action.fontZoomReset",label:r.kg("EditorFontZoomReset.label","Reset Editor Font Size"),alias:"Reset Editor Font Size",precondition:void 0})}run(e,t){n.D.setZoomLevel(0)}}(0,s.Fl)(o),(0,s.Fl)(a),(0,s.Fl)(c)},70983:(e,t,i)=>{"use strict";i.d(t,{A:()=>o});var s,n=i(59284);function r(){return r=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";(0,i(34918).K)({id:"r",extensions:[".r",".rhistory",".rmd",".rprofile",".rt"],aliases:["R","r"],loader:()=>i.e(86658).then(i.bind(i,86658))})},71319:(e,t,i)=>{"use strict";i.d(t,{V:()=>r,w:()=>o});var s=i(31308),n=i(13850);function r(e,t,i){return(0,n.eP)({debugName:()=>`Configuration Key "${e}"`},(t=>i.onDidChangeConfiguration((i=>{i.affectsConfiguration(e)&&t(i)}))),(()=>i.getValue(e)??t))}function o(e,t,i){const n=e.bindTo(t);return(0,s.zL)({debugName:()=>`Set Context Key "${e.key}"`},(e=>{n.set(i(e))}))}},71468:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sol",extensions:[".sol"],aliases:["sol","solidity","Solidity"],loader:()=>i.e(98234).then(i.bind(i,98234))})},71597:(e,t,i)=>{"use strict";i.d(t,{Fd:()=>a,aJ:()=>s});var s,n=i(25890),r=i(5662),o=i(46359);!function(e){e[e.PRESERVE=0]="PRESERVE",e[e.LAST=1]="LAST"}(s||(s={}));const a={Quickaccess:"workbench.contributions.quickaccess"};o.O.add(a.Quickaccess,new class{constructor(){this.providers=[],this.defaultProvider=void 0}registerQuickAccessProvider(e){return 0===e.prefix.length?this.defaultProvider=e:this.providers.push(e),this.providers.sort(((e,t)=>t.prefix.length-e.prefix.length)),(0,r.s)((()=>{this.providers.splice(this.providers.indexOf(e),1),this.defaultProvider===e&&(this.defaultProvider=void 0)}))}getQuickAccessProviders(){return(0,n.Yc)([this.defaultProvider,...this.providers])}getQuickAccessProvider(e){return e&&this.providers.find((t=>e.startsWith(t.prefix)))||void 0||this.defaultProvider}})},71933:(e,t,i)=>{"use strict";i.d(t,{C:()=>ue});var s,n=i(8597),r=i(11007),o=i(64383),a=i(91090),c=i(5662),l=i(83069),h=i(87289),d=i(56942),u=i(55130),g=i(8995),p=i(61407),m=i(98031),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class{static{s=this}static{this.codeActionCommands=[u.Xj,u.k_,u.C9,u.Uy,u.Rw]}constructor(e){this.keybindingService=e}getResolver(){const e=new a.d((()=>this.keybindingService.getKeybindings().filter((e=>s.codeActionCommands.indexOf(e.command)>=0)).filter((e=>e.resolvedKeybinding)).map((e=>{let t=e.commandArgs;return e.command===u.Uy?t={kind:p.gB.SourceOrganizeImports.value}:e.command===u.Rw&&(t={kind:p.gB.SourceFixAll.value}),{resolvedKeybinding:e.resolvedKeybinding,...p.QA.fromUser(t,{kind:g.k.None,apply:"never"})}}))));return t=>{if(t.kind){const i=this.bestKeybindingForCodeAction(t,e.value);return i?.resolvedKeybinding}}}bestKeybindingForCodeAction(e,t){if(!e.kind)return;const i=new g.k(e.kind);return t.filter((e=>e.kind.contains(i))).filter((t=>!t.preferred||e.isPreferred)).reduceRight(((e,t)=>e?e.kind.contains(t.kind)?t:e:t),void 0)}};v=s=f([_(0,m.b)],v);i(97791);var C=i(10350),E=(i(93409),i(78209));const b=Object.freeze({kind:g.k.Empty,title:(0,E.kg)("codeAction.widget.id.more","More Actions...")}),S=Object.freeze([{kind:p.gB.QuickFix,title:(0,E.kg)("codeAction.widget.id.quickfix","Quick Fix")},{kind:p.gB.RefactorExtract,title:(0,E.kg)("codeAction.widget.id.extract","Extract"),icon:C.W.wrench},{kind:p.gB.RefactorInline,title:(0,E.kg)("codeAction.widget.id.inline","Inline"),icon:C.W.wrench},{kind:p.gB.RefactorRewrite,title:(0,E.kg)("codeAction.widget.id.convert","Rewrite"),icon:C.W.wrench},{kind:p.gB.RefactorMove,title:(0,E.kg)("codeAction.widget.id.move","Move"),icon:C.W.wrench},{kind:p.gB.SurroundWith,title:(0,E.kg)("codeAction.widget.id.surround","Surround With"),icon:C.W.surroundWith},{kind:p.gB.Source,title:(0,E.kg)("codeAction.widget.id.source","Source Action"),icon:C.W.symbolFile},b]);var y=i(96758),w=i(99645),R=i(11799),L=i(47625),T=i(93090),x=i(18447),k=i(98067),A=i(25689),N=i(47508),I=i(19070),O=i(66261),D=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},M=function(e,t){return function(i,s){t(i,s,e)}};const P="acceptSelectedCodeAction",F="previewSelectedCodeAction";class U{get templateId(){return"header"}renderTemplate(e){e.classList.add("group-header");const t=document.createElement("span");return e.append(t),{container:e,text:t}}renderElement(e,t,i){i.text.textContent=e.group?.title??""}disposeTemplate(e){}}let H=class{get templateId(){return"action"}constructor(e,t){this._supportsPreview=e,this._keybindingService=t}renderTemplate(e){e.classList.add(this.templateId);const t=document.createElement("div");t.className="icon",e.append(t);const i=document.createElement("span");i.className="title",e.append(i);return{container:e,icon:t,text:i,keybinding:new L.x(e,k.OS)}}renderElement(e,t,i){if(e.group?.icon?(i.icon.className=A.L.asClassName(e.group.icon),e.group.icon.color&&(i.icon.style.color=(0,O.GuP)(e.group.icon.color.id))):(i.icon.className=A.L.asClassName(C.W.lightBulb),i.icon.style.color="var(--vscode-editorLightBulb-foreground)"),!e.item||!e.label)return;i.text.textContent=G(e.label),i.keybinding.set(e.keybinding),n.bo(!!e.keybinding,i.keybinding.element);const s=this._keybindingService.lookupKeybinding(P)?.getLabel(),r=this._keybindingService.lookupKeybinding(F)?.getLabel();i.container.classList.toggle("option-disabled",e.disabled),e.disabled?i.container.title=e.label:s&&r?this._supportsPreview&&e.canPreview?i.container.title=(0,E.kg)({key:"label-preview",comment:['placeholders are keybindings, e.g "F2 to Apply, Shift+F2 to Preview"']},"{0} to Apply, {1} to Preview",s,r):i.container.title=(0,E.kg)({key:"label",comment:['placeholder is a keybinding, e.g "F2 to Apply"']},"{0} to Apply",s):i.container.title=""}disposeTemplate(e){e.keybinding.dispose()}};H=D([M(1,m.b)],H);class B extends UIEvent{constructor(){super("acceptSelectedAction")}}class W extends UIEvent{constructor(){super("previewSelectedAction")}}function V(e){if("action"===e.kind)return e.label}let z=class extends c.jG{constructor(e,t,i,s,n,r){super(),this._delegate=s,this._contextViewService=n,this._keybindingService=r,this._actionLineHeight=24,this._headerLineHeight=26,this.cts=this._register(new x.Qi),this.domNode=document.createElement("div"),this.domNode.classList.add("actionList");const o={getHeight:e=>"header"===e.kind?this._headerLineHeight:this._actionLineHeight,getTemplateId:e=>e.kind};this._list=this._register(new T.B8(e,this.domNode,o,[new H(t,this._keybindingService),new U],{keyboardSupport:!1,typeNavigationEnabled:!0,keyboardNavigationLabelProvider:{getKeyboardNavigationLabel:V},accessibilityProvider:{getAriaLabel:e=>{if("action"===e.kind){let t=e.label?G(e?.label):"";return e.disabled&&(t=(0,E.kg)({key:"customQuickFixWidget.labels",comment:["Action widget labels for accessibility."]},"{0}, Disabled Reason: {1}",t,e.disabled)),t}return null},getWidgetAriaLabel:()=>(0,E.kg)({key:"customQuickFixWidget",comment:["An action widget option"]},"Action Widget"),getRole:e=>"action"===e.kind?"option":"separator",getWidgetRole:()=>"listbox"}})),this._list.style(I.IN),this._register(this._list.onMouseClick((e=>this.onListClick(e)))),this._register(this._list.onMouseOver((e=>this.onListHover(e)))),this._register(this._list.onDidChangeFocus((()=>this.onFocus()))),this._register(this._list.onDidChangeSelection((e=>this.onListSelection(e)))),this._allMenuItems=i,this._list.splice(0,this._list.length,this._allMenuItems),this._list.length&&this.focusNext()}focusCondition(e){return!e.disabled&&"action"===e.kind}hide(e){this._delegate.onHide(e),this.cts.cancel(),this._contextViewService.hideContextView()}layout(e){const t=this._allMenuItems.filter((e=>"header"===e.kind)).length,i=this._allMenuItems.length*this._actionLineHeight+t*this._headerLineHeight-t*this._actionLineHeight;this._list.layout(i);let s=e;if(this._allMenuItems.length>=50)s=380;else{const t=this._allMenuItems.map(((e,t)=>{const i=this.domNode.ownerDocument.getElementById(this._list.getElementID(t));if(i){i.style.width="auto";const e=i.getBoundingClientRect().width;return i.style.width="",e}return 0}));s=Math.max(...t,e)}const n=Math.min(i,.7*this.domNode.ownerDocument.body.clientHeight);return this._list.layout(n,s),this.domNode.style.height=`${n}px`,this._list.domFocus(),s}focusPrevious(){this._list.focusPrevious(1,!0,void 0,this.focusCondition)}focusNext(){this._list.focusNext(1,!0,void 0,this.focusCondition)}acceptSelected(e){const t=this._list.getFocus();if(0===t.length)return;const i=t[0],s=this._list.element(i);if(!this.focusCondition(s))return;const n=e?new W:new B;this._list.setSelection([i],n)}onListSelection(e){if(!e.elements.length)return;const t=e.elements[0];t.item&&this.focusCondition(t)?this._delegate.onSelect(t.item,e.browserEvent instanceof W):this._list.setSelection([])}onFocus(){const e=this._list.getFocus();if(0===e.length)return;const t=e[0],i=this._list.element(t);this._delegate.onFocus?.(i.item)}async onListHover(e){const t=e.element;if(t&&t.item&&this.focusCondition(t)){if(this._delegate.onHover&&!t.disabled&&"action"===t.kind){const e=await this._delegate.onHover(t.item,this.cts.token);t.canPreview=e?e.canPreview:void 0}e.index&&this._list.splice(e.index,1,[t])}this._list.setFocus("number"===typeof e.index?[e.index]:[])}onListClick(e){e.element&&this.focusCondition(e.element)&&this._list.setFocus([])}};function G(e){return e.replace(/\r\n|\r|\n/g," ")}z=D([M(4,N.l),M(5,m.b)],z);var j=i(27195),K=i(32848),Y=i(14718),q=i(63591),$=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Q=function(e,t){return function(i,s){t(i,s,e)}};(0,O.x1A)("actionBar.toggledBackground",O.c1f,(0,E.kg)("actionBar.toggledBackground","Background color for toggled action items in action bar."));const X={Visible:new K.N1("codeActionMenuVisible",!1,(0,E.kg)("codeActionMenuVisible","Whether the action widget list is visible"))},Z=(0,q.u1)("actionWidgetService");let J=class extends c.jG{get isVisible(){return X.Visible.getValue(this._contextKeyService)||!1}constructor(e,t,i){super(),this._contextViewService=e,this._contextKeyService=t,this._instantiationService=i,this._list=this._register(new c.HE)}show(e,t,i,s,n,r,o){const a=X.Visible.bindTo(this._contextKeyService),c=this._instantiationService.createInstance(z,e,t,i,s);this._contextViewService.showContextView({getAnchor:()=>n,render:e=>(a.set(!0),this._renderWidget(e,c,o??[])),onHide:e=>{a.reset(),this._onWidgetClosed(e)}},r,!1)}acceptSelected(e){this._list.value?.acceptSelected(e)}focusPrevious(){this._list?.value?.focusPrevious()}focusNext(){this._list?.value?.focusNext()}hide(e){this._list.value?.hide(e),this._list.clear()}_renderWidget(e,t,i){const s=document.createElement("div");if(s.classList.add("action-widget"),e.appendChild(s),this._list.value=t,!this._list.value)throw new Error("List has no value");s.appendChild(this._list.value.domNode);const r=new c.Cm,o=document.createElement("div"),a=e.appendChild(o);a.classList.add("context-view-block"),r.add(n.ko(a,n.Bx.MOUSE_DOWN,(e=>e.stopPropagation())));const l=document.createElement("div"),h=e.appendChild(l);h.classList.add("context-view-pointerBlock"),r.add(n.ko(h,n.Bx.POINTER_MOVE,(()=>h.remove()))),r.add(n.ko(h,n.Bx.MOUSE_DOWN,(()=>h.remove())));let d=0;if(i.length){const e=this._createActionBar(".action-widget-action-bar",i);e&&(s.appendChild(e.getContainer().parentElement),r.add(e),d=e.getContainer().offsetWidth)}const u=this._list.value?.layout(d);s.style.width=`${u}px`;const g=r.add(n.w5(e));return r.add(g.onDidBlur((()=>this.hide(!0)))),r}_createActionBar(e,t){if(!t.length)return;const i=n.$(e),s=new R.E(i);return s.push(t,{icon:!1,label:!0}),s}_onWidgetClosed(e){this._list.value?.hide(e)}};J=$([Q(0,N.l),Q(1,K.fN),Q(2,q._Y)],J),(0,Y.v)(Z,J,1);const ee=1100;(0,j.ug)(class extends j.L{constructor(){super({id:"hideCodeActionWidget",title:(0,E.aS)("hideCodeActionWidget.title","Hide action widget"),precondition:X.Visible,keybinding:{weight:ee,primary:9,secondary:[1033]}})}run(e){e.get(Z).hide(!0)}}),(0,j.ug)(class extends j.L{constructor(){super({id:"selectPrevCodeAction",title:(0,E.aS)("selectPrevCodeAction.title","Select previous action"),precondition:X.Visible,keybinding:{weight:ee,primary:16,secondary:[2064],mac:{primary:16,secondary:[2064,302]}}})}run(e){const t=e.get(Z);t instanceof J&&t.focusPrevious()}}),(0,j.ug)(class extends j.L{constructor(){super({id:"selectNextCodeAction",title:(0,E.aS)("selectNextCodeAction.title","Select next action"),precondition:X.Visible,keybinding:{weight:ee,primary:18,secondary:[2066],mac:{primary:18,secondary:[2066,300]}}})}run(e){const t=e.get(Z);t instanceof J&&t.focusNext()}}),(0,j.ug)(class extends j.L{constructor(){super({id:P,title:(0,E.aS)("acceptSelected.title","Accept selected action"),precondition:X.Visible,keybinding:{weight:ee,primary:3,secondary:[2137]}})}run(e){const t=e.get(Z);t instanceof J&&t.acceptSelected()}}),(0,j.ug)(class extends j.L{constructor(){super({id:F,title:(0,E.aS)("previewSelected.title","Preview selected action"),precondition:X.Visible,keybinding:{weight:ee,primary:2051}})}run(e){const t=e.get(Z);t instanceof J&&t.acceptSelected(!0)}});var te,ie=i(50091),se=i(84001),ne=i(75147),re=i(73823),oe=i(86723),ae=i(47612),ce=i(59473),le=i(90651),he=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},de=function(e,t){return function(i,s){t(i,s,e)}};let ue=class extends c.jG{static{te=this}static{this.ID="editor.contrib.codeActionController"}static get(e){return e.getContribution(te.ID)}constructor(e,t,i,s,n,r,o,l,h,d,u){super(),this._commandService=o,this._configurationService=l,this._actionWidgetService=h,this._instantiationService=d,this._telemetryService=u,this._activeCodeActions=this._register(new c.HE),this._showDisabled=!1,this._disposed=!1,this._editor=e,this._model=this._register(new ce.Dc(this._editor,n.codeActionProvider,t,i,r,l,this._telemetryService)),this._register(this._model.onDidChangeState((e=>this.update(e)))),this._lightBulbWidget=new a.d((()=>{const e=this._editor.getContribution(y.E.ID);return e&&this._register(e.onClick((e=>this.showCodeActionsFromLightbulb(e.actions,e)))),e})),this._resolver=s.createInstance(v),this._register(this._editor.onDidLayoutChange((()=>this._actionWidgetService.hide())))}dispose(){this._disposed=!0,super.dispose()}async showCodeActionsFromLightbulb(e,t){if(e.allAIFixes&&1===e.validActions.length){const t=e.validActions[0],i=t.action.command;return i&&"inlineChat.start"===i.id&&i.arguments&&i.arguments.length>=1&&(i.arguments[0]={...i.arguments[0],autoSend:!1}),void await this._applyCodeAction(t,!1,!1,u.Qp.FromAILightbulb)}await this.showCodeActionList(e,t,{includeDisabledActions:!1,fromLightbulb:!0})}showCodeActions(e,t,i){return this.showCodeActionList(t,i,{includeDisabledActions:!1,fromLightbulb:!1})}manualTriggerAtCurrentPosition(e,t,i,s){if(!this._editor.hasModel())return;w.k.get(this._editor)?.closeMessage();const n=this._editor.getPosition();this._trigger({type:1,triggerAction:t,filter:i,autoApply:s,context:{notAvailableMessage:e,position:n}})}_trigger(e){return this._model.trigger(e)}async _applyCodeAction(e,t,i,s){try{await this._instantiationService.invokeFunction(u.W4,e,s,{preview:i,editor:this._editor})}finally{t&&this._trigger({type:2,triggerAction:p.fo.QuickFix,filter:{}})}}hideLightBulbWidget(){this._lightBulbWidget.rawValue?.hide(),this._lightBulbWidget.rawValue?.gutterHide()}async update(e){if(1!==e.type)return void this.hideLightBulbWidget();let t;try{t=await e.actions}catch(s){return void(0,o.dz)(s)}if(this._disposed)return;const i=this._editor.getSelection();if(i?.startLineNumber===e.position.lineNumber)if(this._lightBulbWidget.value?.update(t,e.trigger,e.position),1===e.trigger.type){if(e.trigger.filter?.include){const i=this.tryGetValidActionToApply(e.trigger,t);if(i){try{this.hideLightBulbWidget(),await this._applyCodeAction(i,!1,!1,u.Qp.FromCodeActions)}finally{t.dispose()}return}if(e.trigger.context){const i=this.getInvalidActionThatWouldHaveBeenApplied(e.trigger,t);if(i&&i.action.disabled)return w.k.get(this._editor)?.showMessage(i.action.disabled,e.trigger.context.position),void t.dispose()}}const i=!!e.trigger.filter?.include;if(e.trigger.context&&(!t.allActions.length||!i&&!t.validActions.length))return w.k.get(this._editor)?.showMessage(e.trigger.context.notAvailableMessage,e.trigger.context.position),this._activeCodeActions.value=t,void t.dispose();this._activeCodeActions.value=t,this.showCodeActionList(t,this.toCoords(e.position),{includeDisabledActions:i,fromLightbulb:!1})}else this._actionWidgetService.isVisible?t.dispose():this._activeCodeActions.value=t}getInvalidActionThatWouldHaveBeenApplied(e,t){if(t.allActions.length)return"first"===e.autoApply&&0===t.validActions.length||"ifSingle"===e.autoApply&&1===t.allActions.length?t.allActions.find((({action:e})=>e.disabled)):void 0}tryGetValidActionToApply(e,t){if(t.validActions.length)return"first"===e.autoApply&&t.validActions.length>0||"ifSingle"===e.autoApply&&1===t.validActions.length?t.validActions[0]:void 0}static{this.DECORATION=h.kI.register({description:"quickfix-highlight",className:"quickfix-edit-highlight"})}async showCodeActionList(e,t,i){const s=this._editor.createDecorationsCollection(),n=this._editor.getDomNode();if(!n)return;const o=i.includeDisabledActions&&(this._showDisabled||0===e.validActions.length)?e.allActions:e.validActions;if(!o.length)return;const a=l.y.isIPosition(t)?this.toCoords(t):t,c={onSelect:async(e,t)=>{this._applyCodeAction(e,!0,!!t,i.fromLightbulb?u.Qp.FromAILightbulb:u.Qp.FromCodeActions),this._actionWidgetService.hide(!1),s.clear()},onHide:e=>{this._editor?.focus(),s.clear()},onHover:async(e,t)=>{if(t.isCancellationRequested)return;let i=!1;const s=e.action.kind;if(s){const e=new g.k(s);i=[p.gB.RefactorExtract,p.gB.RefactorInline,p.gB.RefactorRewrite,p.gB.RefactorMove,p.gB.Source].some((t=>t.contains(e)))}return{canPreview:i||!!e.action.edit?.edits.length}},onFocus:e=>{if(e&&e.action){const t=e.action.ranges,i=e.action.diagnostics;if(s.clear(),t&&t.length>0){const e=i&&i?.length>1?i.map((e=>({range:e,options:te.DECORATION}))):t.map((e=>({range:e,options:te.DECORATION})));s.set(e)}else if(i&&i.length>0){const e=i.map((e=>({range:e,options:te.DECORATION})));s.set(e);const t=i[0];if(t.startLineNumber&&t.startColumn){const e=this._editor.getModel()?.getWordAtPosition({lineNumber:t.startLineNumber,column:t.startColumn})?.word;r.h5((0,E.kg)("editingNewSelection","Context: {0} at line {1} and column {2}.",e,t.startLineNumber,t.startColumn))}}}else s.clear()}};this._actionWidgetService.show("codeActionWidget",!0,function(e,t,i){if(!t)return e.map((e=>({kind:"action",item:e,group:b,disabled:!!e.action.disabled,label:e.action.disabled||e.action.title,canPreview:!!e.action.edit?.edits.length})));const s=S.map((e=>({group:e,actions:[]})));for(const r of e){const e=r.action.kind?new g.k(r.action.kind):g.k.None;for(const t of s)if(t.group.kind.contains(e)){t.actions.push(r);break}}const n=[];for(const r of s)if(r.actions.length){n.push({kind:"header",group:r.group});for(const e of r.actions){const t=r.group;n.push({kind:"action",item:e,group:e.action.isAI?{title:t.title,kind:t.kind,icon:C.W.sparkle}:t,label:e.action.title,disabled:!!e.action.disabled,keybinding:i(e.action)})}}return n}(o,this._shouldShowHeaders(),this._resolver.getResolver()),c,a,n,this._getActionBarActions(e,t,i))}toCoords(e){if(!this._editor.hasModel())return{x:0,y:0};this._editor.revealPosition(e,1),this._editor.render();const t=this._editor.getScrolledVisiblePosition(e),i=(0,n.BK)(this._editor.getDomNode());return{x:i.left+t.left,y:i.top+t.top+t.height}}_shouldShowHeaders(){const e=this._editor?.getModel();return this._configurationService.getValue("editor.codeActionWidget.showHeaders",{resource:e?.uri})}_getActionBarActions(e,t,i){if(i.fromLightbulb)return[];const s=e.documentation.map((e=>({id:e.id,label:e.title,tooltip:e.tooltip??"",class:void 0,enabled:!0,run:()=>this._commandService.executeCommand(e.id,...e.arguments??[])})));return i.includeDisabledActions&&e.validActions.length>0&&e.allActions.length!==e.validActions.length&&s.push(this._showDisabled?{id:"hideMoreActions",label:(0,E.kg)("hideMoreActions","Hide Disabled"),enabled:!0,tooltip:"",class:void 0,run:()=>(this._showDisabled=!1,this.showCodeActionList(e,t,i))}:{id:"showMoreActions",label:(0,E.kg)("showMoreActions","Show Disabled"),enabled:!0,tooltip:"",class:void 0,run:()=>(this._showDisabled=!0,this.showCodeActionList(e,t,i))}),s}};ue=te=he([de(1,ne.DR),de(2,K.fN),de(3,q._Y),de(4,d.ILanguageFeaturesService),de(5,re.N8),de(6,ie.d),de(7,se.pG),de(8,Z),de(9,q._Y),de(10,le.k)],ue),(0,ae.zy)(((e,t)=>{var i,s;i=".quickfix-edit-highlight",(s=e.getColor(O.Ubg))&&t.addRule(`.monaco-editor ${i} { background-color: ${s}; }`);const n=e.getColor(O.ECk);n&&t.addRule(`.monaco-editor .quickfix-edit-highlight { border: 1px ${(0,oe.Bb)(e.type)?"dotted":"solid"} ${n}; box-sizing: border-box; }`)}))},71964:(e,t,i)=>{"use strict";i.d(t,{i:()=>r,y:()=>o});var s=i(36677),n=i(75326);class r{constructor(e,t,i){this._range=e,this._charBeforeSelection=t,this._charAfterSelection=i}getEditOperations(e,t){t.addTrackedEditOperation(new s.Q(this._range.startLineNumber,this._range.startColumn,this._range.startLineNumber,this._range.startColumn),this._charBeforeSelection),t.addTrackedEditOperation(new s.Q(this._range.endLineNumber,this._range.endColumn,this._range.endLineNumber,this._range.endColumn),this._charAfterSelection)}computeCursorState(e,t){const i=t.getInverseEditOperations(),s=i[0].range,r=i[1].range;return new n.L(s.endLineNumber,s.endColumn,r.endLineNumber,r.endColumn-this._charAfterSelection.length)}}class o{constructor(e,t,i){this._position=e,this._text=t,this._charAfter=i}getEditOperations(e,t){t.addTrackedEditOperation(new s.Q(this._position.lineNumber,this._position.column,this._position.lineNumber,this._position.column),this._text+this._charAfter)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return new n.L(i.endLineNumber,i.startColumn,i.endLineNumber,i.endColumn-this._charAfter.length)}}},72093:(e,t,i)=>{"use strict";i.d(t,{A:()=>h});const s={randomUUID:"undefined"!==typeof crypto&&crypto.randomUUID&&crypto.randomUUID.bind(crypto)};var n,r=new Uint8Array(16);function o(){if(!n&&!(n="undefined"!==typeof crypto&&crypto.getRandomValues&&crypto.getRandomValues.bind(crypto)))throw new Error("crypto.getRandomValues() not supported. See https://github.com/uuidjs/uuid#getrandomvalues-not-supported");return n(r)}for(var a=[],c=0;c<256;++c)a.push((c+256).toString(16).slice(1));function l(e,t=0){return(a[e[t+0]]+a[e[t+1]]+a[e[t+2]]+a[e[t+3]]+"-"+a[e[t+4]]+a[e[t+5]]+"-"+a[e[t+6]]+a[e[t+7]]+"-"+a[e[t+8]]+a[e[t+9]]+"-"+a[e[t+10]]+a[e[t+11]]+a[e[t+12]]+a[e[t+13]]+a[e[t+14]]+a[e[t+15]]).toLowerCase()}const h=function(e,t,i){if(s.randomUUID&&!t&&!e)return s.randomUUID();var n=(e=e||{}).random||(e.rng||o)();if(n[6]=15&n[6]|64,n[8]=63&n[8]|128,t){i=i||0;for(var r=0;r<16;++r)t[i+r]=n[r];return t}return l(n)}},72466:(e,t,i)=>{"use strict";i.d(t,{T:()=>r,x:()=>n});const s=[];function n(e){s.push(e)}function r(){return s.slice(0)}},72962:(e,t,i)=>{"use strict";i.d(t,{Z:()=>l});var s=i(60413),n=i(24939),r=i(42539),o=i(98067);const a=o.zx?256:2048,c=o.zx?2048:256;class l{constructor(e){this._standardKeyboardEventBrand=!0;const t=e;this.browserEvent=t,this.target=t.target,this.ctrlKey=t.ctrlKey,this.shiftKey=t.shiftKey,this.altKey=t.altKey,this.metaKey=t.metaKey,this.altGraphKey=t.getModifierState?.("AltGraph"),this.keyCode=function(e){if(e.charCode){const t=String.fromCharCode(e.charCode).toUpperCase();return n.YM.fromString(t)}const t=e.keyCode;if(3===t)return 7;if(s.gm)switch(t){case 59:return 85;case 60:if(o.j9)return 97;break;case 61:return 86;case 107:return 109;case 109:return 111;case 173:return 88;case 224:if(o.zx)return 57}else if(s.Tc){if(o.zx&&93===t)return 57;if(!o.zx&&92===t)return 57}return n.uw[t]||0}(t),this.code=t.code,this.ctrlKey=this.ctrlKey||5===this.keyCode,this.altKey=this.altKey||6===this.keyCode,this.shiftKey=this.shiftKey||4===this.keyCode,this.metaKey=this.metaKey||57===this.keyCode,this._asKeybinding=this._computeKeybinding(),this._asKeyCodeChord=this._computeKeyCodeChord()}preventDefault(){this.browserEvent&&this.browserEvent.preventDefault&&this.browserEvent.preventDefault()}stopPropagation(){this.browserEvent&&this.browserEvent.stopPropagation&&this.browserEvent.stopPropagation()}toKeyCodeChord(){return this._asKeyCodeChord}equals(e){return this._asKeybinding===e}_computeKeybinding(){let e=0;5!==this.keyCode&&4!==this.keyCode&&6!==this.keyCode&&57!==this.keyCode&&(e=this.keyCode);let t=0;return this.ctrlKey&&(t|=a),this.altKey&&(t|=512),this.shiftKey&&(t|=1024),this.metaKey&&(t|=c),t|=e,t}_computeKeyCodeChord(){let e=0;return 5!==this.keyCode&&4!==this.keyCode&&6!==this.keyCode&&57!==this.keyCode&&(e=this.keyCode),new r.dG(this.ctrlKey,this.shiftKey,this.altKey,this.metaKey,e)}}},73020:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"qsharp",extensions:[".qs"],aliases:["Q#","qsharp"],loader:()=>i.e(5866).then(i.bind(i,5866))})},73157:(e,t,i)=>{"use strict";i.d(t,{M:()=>n});var s=i(55275);function n(e,t){e instanceof s.D?(e.setFontFamily(t.getMassagedFontFamily()),e.setFontWeight(t.fontWeight),e.setFontSize(t.fontSize),e.setFontFeatureSettings(t.fontFeatureSettings),e.setFontVariationSettings(t.fontVariationSettings),e.setLineHeight(t.lineHeight),e.setLetterSpacing(t.letterSpacing)):(e.style.fontFamily=t.getMassagedFontFamily(),e.style.fontWeight=t.fontWeight,e.style.fontSize=t.fontSize+"px",e.style.fontFeatureSettings=t.fontFeatureSettings,e.style.fontVariationSettings=t.fontVariationSettings,e.style.lineHeight=t.lineHeight+"px",e.style.letterSpacing=t.letterSpacing+"px")}},73253:(e,t,i)=>{"use strict";i.d(t,{og:()=>L,SO:()=>me});var s=i(7252);function n(e,t){const i=document.createElement("button");return i.innerText=e,i.className=`paranoid-button paranoid-button_${t}`,i}const r="ParanoidC";function o(e,t){const i=document.getElementById(e);if(!i)throw new Error(`Not found element with id ${e}`);i.style.position="relative";const o=n("+","plus"),a=n("-","minus"),c=n("1:1","normal"),l=function(e,t){const i=document.createElement("canvas");i.setAttribute("id",r),i.setAttribute("width",String(e.offsetWidth)),i.setAttribute("height",String(e.offsetHeight)),e.appendChild(i);const n=t.colors||{};return new s.fabric.Canvas(r,{selection:!1,backgroundColor:n.fill,defaultCursor:"grab"})}(i,t),h=function(e,t,i,s){const n=document.createElement("div");n.className="paranoid-controls";const r=document.createElement("style");return r.innerText=function(e){return`\n .paranoid-controls {\n position: absolute;\n top: 10px;\n right: 10px;\n }\n .paranoid-button {\n margin-left: 12px;\n border-radius: 4px;\n height: 36px;\n width: 36px;\n line-height: 13px;\n font-family: Arial, sans-serif;\n font-size: 13px;\n text-align: center;\n padding: 0;\n box-shadow: 0px 5px 6px ${e.nodeShadow};\n border: 1px solid ${e.buttonBorderColor};\n background-color: ${e.nodeFill};\n color: ${e.textColor};\n cursor: pointer;\n }\n .paranoid-button:focus {\n outline: none;\n }\n .paranoid-button:active {\n border: 1px solid ${e.buttonBorderColor};\n }\n .paranoid-button_plus {\n margin-left: 0;\n border-left: none;\n border-top-left-radius: 0;\n border-bottom-left-radius: 0;\n }\n .paranoid-button_minus {\n border-top-right-radius: 0;\n border-bottom-right-radius: 0;\n }\n`}(s),n.appendChild(r),n.appendChild(t),n.appendChild(e),n.appendChild(i),n}(o,a,c,t.colors);return i.appendChild(h),function(e,t,i,s,n){const r=n.minZoom||.2,o=n.zoomStep||.2,a=n.maxZoom||2,c=n.startZoom||1;e.setZoom(c),i.addEventListener("click",(t=>{t.preventDefault(),t.stopPropagation();let i=e.getZoom();i-=o,i{t.preventDefault(),t.stopPropagation();let i=e.getZoom();i+=o,i>a&&(i=a),e.setZoom(i)})),s.addEventListener("click",(t=>{t.preventDefault(),t.stopPropagation(),e.setZoom(1)}))}(l,o,a,c,t),function(e){let t=!1,i=0,s=0;e.on("mouse:down",(n=>{n.target||(e.setCursor("grabbing"),t=!0,i=n.pointer.x,s=n.pointer.y)})),e.on("mouse:move",(n=>{t&&(e.viewportTransform[4]+=n.pointer.x-i,e.viewportTransform[5]+=n.pointer.y-s,e.setCursor("grabbing"),e.getObjects().forEach((e=>e.setCoords())),e.requestRenderAll(),i=n.pointer.x,s=n.pointer.y)})),e.on("mouse:up",(()=>{t&&(e.setCursor("grab"),t=!1)}))}(l),l}const a={success:"rgba(59, 201, 53, 0.75)",error:"#ff0400",warning:"#ff7700",errorBackground:"rgba(235,50,38,0.08)",warningBackground:"rgba(255,219,77,0.3)",mute:"rgba(0,0,0,0.15)",stroke:"rgba(0,0,0,0.3)",fill:"#fafafa",nodeFill:"#ffffff",nodeShadow:"rgba(0,0,0,0.15)",titleColor:"#000000",textColor:"rgba(0,0,0,0.7)",buttonBorderColor:"rgba(0,0,0,0.07)",groupBorderColor:"rgba(2, 123, 243, 0.14)",groupFill:"rgba(2, 123, 243, 0.08)",titleHoverColor:"#004080",nodeHover:"#f3f3f3",specialHover:"rgba(2,123,243,1)"},c={hasControls:!1,hasRotatingPoint:!1,lockMovementX:!0,lockMovementY:!0,selectable:!1,hoverCursor:"default",subTargetCheck:!0},l="Arial, sans-serif",h=13,d=1.38;var u;!function(e){e.Group="GROUP"}(u||(u={}));i(32133);class g{constructor(e,t){this.children=[],this.members=[],this.data=e,this.canvasNode=t}add(e,t){const i=new g(e,t);i.addParent(this),this.children.push(i)}addNode(e){e.addParent(this),this.children.push(e)}addNodes(e){e.forEach((e=>{e.addParent(this)})),this.children=this.children.concat(e)}addCanvasNode(e){this.canvasNode=e}addShapeInstance(e){this.shapeInstance=e}hasChildren(){return this.children.length>0}addParent(e){this.parent=e}getLeftSibling(){if(!this.parent)return;const e=this.parent.children.findIndex((e=>e===this));return this.parent.children[e-1]}getRightSibling(){if(!this.parent)return;const e=this.parent.children.findIndex((e=>e===this));return this.parent.children[e+1]}}class p{constructor(e){this.nodesWithChildren=[],this.root=e}traverseBF(e){const t=[this.root];for(;t.length>0;){const i=t.shift();i&&(t.push(...i.children),e(i))}}traverseDF(e){const t=[this.root];for(;t.length;){const i=t.shift();let s=!1;i&&(i.children.length>0?t.unshift(...i.children):s=!0,e(i,s))}}traverseByLevels(e){let t=0,i=this.root.children;for(e([this.root],0);i.length>0;)t++,e(i,t),i=i.reduce(((e,t)=>e.concat(t.children)),[])}getTreeDepth(){let e=0;return this.traverseByLevels(((t,i)=>{e=i})),e}setCanvas(e){this.canvas=e}setNodesWithChildren(e){this.nodesWithChildren=e}}class m{constructor(e,t){this.nodes=new Map,this.data=e,this.opts=t}parseData(){const e=this.data,t=this.getGroups(e),i=[...e.nodes];t.forEach(((e,t)=>{i.push({name:t,children:e,type:u.Group})}));const s=this.findSources(i,e.links);let n=[],r={},o=new Map;return s.forEach((t=>{const s=this.mapNodesToTree(t,i,e.links);r=Object.assign(Object.assign({},s.groups),r),o=new Map([...o,...s.notGroupMemebersChildren]),n.push(s.tree)})),o.forEach(((e,t)=>{r[t]&&r[t].addNodes(e)})),n=n.reduce(((e,t)=>{const i=t.root.data.group;return i?r[i].members.push(t):e.push(t),e}),[]),n}getGroups({nodes:e}){const t=new Map;return e.forEach((e=>{if(e.group){const i=t.get(e.group);i?i.push(e.name):t.set(e.group,[e.name])}})),t}findSources(e,t){const i=t.map((({to:e})=>e));return e.reduce(((e,t)=>(i.includes(t.name)||e.push(t),e)),[])}mapNodesToTree(e,t,i){var s;const n=this.createNode(e),r={};this.appendGoup(r,n);const o=t.map((e=>{const t=i.reduce(((t,i)=>(i.from===e.name&&t.push(i.to),t)),[]);return Object.assign(Object.assign({},e),{children:t})})),a=this.getAppender(o,r)(n,(null===(s=o.find((t=>t.name===e.name)))||void 0===s?void 0:s.children)||[]);return{tree:new p(n),groups:r,notGroupMemebersChildren:a}}appendGoup(e,t){const i=t.data;t.data.type===u.Group&&(e[i.name]=t)}getAppender(e,t){const i=new Map,s=(n,r)=>{const o=r.map((i=>{const n=e.find((({name:e})=>e===i)),r=this.createNode(n);return this.appendGoup(t,r),n.children.length>0&&s(r,n.children),r})),a=n.data.group,c=Boolean(a),l=[],h=[];if(o.forEach((e=>{const t=e.data.group;c?a===t?l.push(e):h.push(e):l.push(e)})),n.addNodes(l),a&&h.length>0){const e=i.get(a);e?e.push(...h):i.set(a,h)}return i};return s}createNode(e){const t=new g(e);return this.nodes.set(e.name,t),t}}class f extends CustomEvent{}class _ extends EventTarget{dispatch(e,t){this.dispatchEvent(new f(e,{detail:t}))}}function v(e){switch(e){case 0:return 0;case 1:return 16;default:return 24}}function C(e,t,i,s,n,r){const o=function(e,t,i,s,n,r,o){const a=new Map,c=new Map,l=new Map,h=[];return s.traverseBF((s=>{const{object:n,width:r,height:c}=function(e,t,i,s,n,r,o){var a,c;const l=null!==(a=t.shapeInstance)&&void 0!==a?a:r.node(e,{top:i,left:s},t,n,o),h=null!==(c=t.canvasNode)&&void 0!==c?c:l.getShape();return t.addShapeInstance(l),t.addCanvasNode(h),{object:h,top:i,left:s,width:h.getScaledWidth(),height:h.getScaledHeight()}}(e,s,0,0,t,i,o);a.set(s,{width:r,height:c}),h.push(n)})),function e(t){const{width:i}=a.get(t);let s=i,n=0;if(t.parent&&1===t.parent.children.length&&c.has(t.parent)){const e=c.get(t.parent);s0&&(n=16*(t.children.length-1)+t.children.reduce(((t,i)=>t+e(i)),0),l.set(t,n)),s=Math.max(s,n),c.set(t,s),s}(s.root),function e(t,i,s){let n=s,r=s;for(const o of t){const{width:t,height:s}=a.get(o),h=c.get(o),d=i,u=n+Math.floor(h/2)-Math.floor(t/2);if(o.canvasNode.set({top:d,left:u}),o.canvasNode.setCoords(),n=n+h+16,o.children.length){let t=0;const n=l.get(o);n{a=Math.max(a,(e.left||0)+e.getScaledWidth()),c=Math.max(c,(e.top||0)+e.getScaledHeight())})),{nodes:o,bottom:c,right:a}}function E(e){const t=e.canvasNode;if(t){const e=t.left||0,i=(t.top||0)+t.getScaledHeight();return{x:e+t.getScaledWidth()/2,y:i}}return{x:0,y:0}}function b(e){const t=e.canvasNode;if(t){const e=t.left||0,i=t.top||0;return{x:e+t.getScaledWidth()/2,y:i}}return{x:0,y:0}}class S{constructor(e,t,i,s){this.canvas=o(e,t),this.parser=new m(i,t),this.opts=t,this.shapes=s,this.em=new _,this.trees=[],this.nodes=[],this.links=[],this.listenNodeResize()}render(){requestAnimationFrame((()=>{this.trees=this.parser.parseData(),this.renderIntoCanvas(),this.opts.initialZoomFitsCanvas&&this.zoomObjectsToFitCanvas()}))}destroy(){const e=document.getElementById(r);e&&(this.canvas.dispose(),e.remove())}getEventEmmiter(){return this.em}getGraphNode(e){return this.parser.nodes.get(e)}getOpts(){return this.opts}getColors(){return this.opts.colors}getCanvas(){return this.canvas}renderIntoCanvas(){this.nodes.forEach((e=>{this.canvas.remove(e)})),this.nodes=[],this.links.forEach((e=>{this.canvas.remove(e)})),this.links=[];const e=this.canvas.getHeight()||0,t=this.canvas.getWidth()||0;let i=e,n=t;const r=this.opts.initialTop;let o=this.opts.initialLeft;this.trees.forEach((e=>{e.setCanvas(this.canvas);const{nodes:t,bottom:s,right:a}=C(e,r,o,this.opts,this.shapes,this.em);o=a+15,i=Math.max(s,i),n=Math.max(a,n),this.nodes.push(...t),this.canvas.add(...t)}));const a=function(e,t){const i=t.colors,n=[];return e.data.links.reduce(((t,{from:r})=>{const o=e.nodes.get(r);if(o&&1===o.children.length&&!n.includes(r)){const{x:e,y:a}=E(o),l=new s.fabric.Path(`M ${e} ${a}\n V ${a+16}`,{fill:"",stroke:i.stroke,strokeWidth:1});t.push(new s.fabric.Group([l],Object.assign({},c))),n.push(r)}if(o&&o.children.length>1&&!n.includes(r)){const{x:e,y:a}=E(o),l=12,h=6,d=[new s.fabric.Path(`M ${e} ${a}\n V ${a+l}`,{fill:"",stroke:i.stroke,strokeWidth:1})],{x:u,y:g}=b(o.children[0]),{x:p,y:m}=b(o.children[o.children.length-1]),f=new s.fabric.Path(`M ${u} ${g}\n V ${g-l+h}\n Q ${u} ${g-l} ${u+h} ${g-l}\n H ${p-h}\n Q ${p} ${m-l} ${p} ${m+h-l}\n V ${m}\n `,{fill:"",stroke:i.stroke,strokeWidth:1});d.push(f),o.children.forEach(((e,t)=>{if(0===t||t===o.children.length-1)return;const{x:n,y:r}=b(e),a=new s.fabric.Path(`M ${n} ${r}\n V ${r-l}\n `,{fill:"",stroke:i.stroke,strokeWidth:1});d.push(a)})),t.push(new s.fabric.Group(d,Object.assign({},c))),n.push(r)}return t}),[])}(this.parser,this.opts);this.links.push(...a),this.canvas.add(...a),this.bringNodesToFront()}bringNodesToFront(){var e;const t=null===(e=this.parser)||void 0===e?void 0:e.nodes;t&&t.forEach((e=>{e.canvasNode&&e.canvasNode.bringToFront()}))}listenNodeResize(){this.em.addEventListener("node:resize",(()=>{this.renderIntoCanvas()}))}zoomObjectsToFitCanvas(){let e=0,t=0;this.canvas.getObjects().forEach((i=>{const{top:s,left:n,height:r,width:o}=i.getBoundingRect(),a=n+o,c=s+r;a>e&&(e=a),c>t&&(t=c)})),e+=this.opts.initialLeft,t+=this.opts.initialTop;const i=this.canvas.getWidth()/e,n=this.canvas.getHeight()/t,r=Math.min(i,n);if(r<1){this.canvas.setZoom(r);const e=this.opts.initialTop*r,t=this.opts.initialLeft*r,i=this.opts.initialTop-e,n=this.opts.initialLeft-t;this.canvas.relativePan(new s.fabric.Point(n,i))}}}function y(){const e={success:"--g-color-text-positive",error:"--g-color-text-danger",warning:"--g-color-text-warning",errorBackground:"--g-color-base-danger-light",warningBackground:"--g-color-base-warning-light",mute:"--g-color-line-generic",stroke:"--g-color-text-hint",fill:"--g-color-base-generic-ultralight",nodeFill:"--g-color-base-float",nodeShadow:"--g-color-sfx-shadow",titleColor:"--g-color-text-primary",textColor:"--g-color-text-complementary",buttonBorderColor:"--g-color-line-generic",groupBorderColor:"--g-color-base-info-light-hover",groupFill:"--g-color-base-info-light",titleHoverColor:"--g-color-text-link-hover",nodeHover:"--g-color-base-float-hover",specialHover:"--g-color-line-brand"},t=getComputedStyle(document.body),i=Object.keys(e).reduce(((i,s)=>{const n=t.getPropertyValue(e[s]).replace(/ /g,"");return n&&(i[s]=n),i}),{});return Object.assign(Object.assign(Object.assign({},a),i),{getCommonColor:e=>t.getPropertyValue(`--g-color-${e}`).replace(/ /g,"")})}const w={linkType:"arrow"};function R(e=w){const t=e.colors||{};return Object.assign(Object.assign({initialTop:10,initialLeft:10},e),{colors:Object.assign(Object.assign(Object.assign({},a),y()),t)})}function L(e,t,i,s){const n=R(i);return new S(e,n,t,s)}var T=i(59284),x=(i(43781),i(62060),function(){if("undefined"!==typeof Map)return Map;function e(e,t){var i=-1;return e.some((function(e,s){return e[0]===t&&(i=s,!0)})),i}return function(){function t(){this.__entries__=[]}return Object.defineProperty(t.prototype,"size",{get:function(){return this.__entries__.length},enumerable:!0,configurable:!0}),t.prototype.get=function(t){var i=e(this.__entries__,t),s=this.__entries__[i];return s&&s[1]},t.prototype.set=function(t,i){var s=e(this.__entries__,t);~s?this.__entries__[s][1]=i:this.__entries__.push([t,i])},t.prototype.delete=function(t){var i=this.__entries__,s=e(i,t);~s&&i.splice(s,1)},t.prototype.has=function(t){return!!~e(this.__entries__,t)},t.prototype.clear=function(){this.__entries__.splice(0)},t.prototype.forEach=function(e,t){void 0===t&&(t=null);for(var i=0,s=this.__entries__;i0},e.prototype.connect_=function(){k&&!this.connected_&&(document.addEventListener("transitionend",this.onTransitionEnd_),window.addEventListener("resize",this.refresh),O?(this.mutationsObserver_=new MutationObserver(this.refresh),this.mutationsObserver_.observe(document,{attributes:!0,childList:!0,characterData:!0,subtree:!0})):(document.addEventListener("DOMSubtreeModified",this.refresh),this.mutationEventsAdded_=!0),this.connected_=!0)},e.prototype.disconnect_=function(){k&&this.connected_&&(document.removeEventListener("transitionend",this.onTransitionEnd_),window.removeEventListener("resize",this.refresh),this.mutationsObserver_&&this.mutationsObserver_.disconnect(),this.mutationEventsAdded_&&document.removeEventListener("DOMSubtreeModified",this.refresh),this.mutationsObserver_=null,this.mutationEventsAdded_=!1,this.connected_=!1)},e.prototype.onTransitionEnd_=function(e){var t=e.propertyName,i=void 0===t?"":t;I.some((function(e){return!!~i.indexOf(e)}))&&this.refresh()},e.getInstance=function(){return this.instance_||(this.instance_=new e),this.instance_},e.instance_=null,e}(),M=function(e,t){for(var i=0,s=Object.keys(t);i0},e}(),Y="undefined"!==typeof WeakMap?new WeakMap:new x,q=function e(t){if(!(this instanceof e))throw new TypeError("Cannot call a class as a function.");if(!arguments.length)throw new TypeError("1 argument required, but only 0 present.");var i=D.getInstance(),s=new K(t,i,this);Y.set(this,s)};["observe","unobserve","disconnect"].forEach((function(e){q.prototype[e]=function(){var t;return(t=Y.get(this))[e].apply(t,arguments)}}));"undefined"!==typeof A.ResizeObserver&&A.ResizeObserver;T.Component;T.Component;var $=i(87924),Q=i.n($);const X={width:280,expandedWidth:360,borderRadius:4,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:12,timeMaxWidth:25,percentageMaxWidth:25,textOffset:8,tagLeftOffset:4,tagTopOffset:5,statsOffset:24};class Z{constructor(e,t,i,s){this.top=0,this.left=0,this.canvas=e,this.stats=t,this.coords=i,this.colors=s,this.textProps={fontSize:X.textFontSize,lineHeight:X.textLineHeight,fontFamily:l,fill:null===s||void 0===s?void 0:s.titleColor},this.selectedGroup=t[0].group;const n=this.createTitles(),r=n.map((e=>e.getScaledHeight())),o=Math.max.apply(null,r);this.lineTop=this.top+o+X.textOffset;const a=this.createLine();this.content=this.createContent(n),this.group=this.createGroup(n,a,this.content),this.initListeners()}getCanvasObject(){return this.group}createTitles(){let e=this.left;return this.stats.map((({group:e})=>e)).map((t=>{var i,n;const r=new s.fabric.Text(t,Object.assign(Object.assign({left:e,top:this.top},this.textProps),{fill:t===this.selectedGroup?null===(i=this.colors)||void 0===i?void 0:i.titleColor:null===(n=this.colors)||void 0===n?void 0:n.textColor}));return e+=r.getScaledWidth()+X.statsOffset,r}))}createLine(){return new s.fabric.Path(`M ${this.left} ${this.lineTop}\n H ${X.expandedWidth-2*X.padding}`,{fill:"",stroke:this.colors.stroke,strokeWidth:1})}createContent(e){return this.stats.map((({group:t,stats:i},n)=>{const r=this.getContentItems(i,this.lineTop),o=e[n],a=o.left||0,c=a+o.getScaledWidth();return{group:t,items:new s.fabric.Group(r,{opacity:this.selectedGroup===t?1:0}),title:o,hoverLine:this.createHoverLine(a,c,t)}}))}getContentItems(e,t){let i=t+2*X.textOffset;const n=[],r=e=>{e.forEach((({name:e,value:t})=>{var r;const o=new s.fabric.Text(e,Object.assign({left:this.left,top:i},this.textProps)),a=X.expandedWidth/2-X.padding,c=X.expandedWidth-2*X.padding,l=new s.fabric.Textbox(String(t),Object.assign(Object.assign({left:a,top:i},this.textProps),{fill:null===(r=this.colors)||void 0===r?void 0:r.textColor,splitByGrapheme:!0,width:c-a}));n.push(o,l),i+=Math.max(o.getScaledHeight(),l.getScaledHeight())+X.textOffset}))};return!function(e){var t;return Boolean(null===(t=e[0])||void 0===t?void 0:t.items)}(e)?r(e):e.forEach((({name:t,items:o},a)=>{const c=new s.fabric.Text(t,Object.assign(Object.assign({left:this.left,top:i},this.textProps),{fontWeight:"bold"}));if(n.push(c),i+=c.getScaledHeight()+X.textOffset,r(o),a!==e.length-1){const e=new s.fabric.Path(`M ${this.left} ${i}\n H ${X.expandedWidth-2*X.padding}`,{fill:"",stroke:this.colors.stroke,strokeWidth:1,strokeDashArray:[6,4]});n.push(e),i+=e.getScaledHeight()+X.textOffset}})),n}createGroup(e,t,i){const n=i.map((({items:e})=>e)),r=i.map((({hoverLine:e})=>e));return new s.fabric.Group([...e,t,...n,...r],Object.assign({left:this.coords.left,top:this.coords.top},c))}createHoverLine(e,t,i){return new s.fabric.Path(`M ${e} ${this.lineTop-1}\n H ${t}`,{fill:"",stroke:this.colors.specialHover,strokeWidth:2,opacity:this.selectedGroup===i?1:0})}initListeners(){this.content.forEach((({group:e,title:t,items:i,hoverLine:s})=>{t.on("mousedown",(()=>{const n=this.selectedGroup,r=this.content.find((e=>e.group===n));r&&(r.title.set({fill:this.colors.textColor}),r.items.set({opacity:0}),r.hoverLine.set({opacity:0}),t.set({fill:this.colors.titleColor}),i.set({opacity:1}),s.set({opacity:1}),this.selectedGroup=e,this.canvas.requestRenderAll())}))}))}}function J(e,t,i,s,n){return new Z(e,t,{top:i,left:s},n).getCanvasObject()}function ee(e,t,i){return new s.fabric.Textbox(e?`#${e}`:"",{fontSize:12,lineHeight:14,textAlign:"right",fontFamily:l,fill:i.getCommonColor("text-secondary"),hoverCursor:t?"pointer":"default"})}const te={width:112,expandedWidth:360,borderRadius:6,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:16,textOffset:8},ie={scaleX:16/512,scaleY:16/512,originY:"center"};function se(e,t,i){const n=new s.fabric.Text(e,{fontSize:te.textFontSize,lineHeight:te.textFontSize,fontFamily:l,fill:i.getCommonColor("text-misc"),originY:"center"}),r=[n];let o;switch(e){case"Merge":o=new s.fabric.Path("M232.5 5.171C247.4-1.718 264.6-1.718 279.5 5.171L498.1 106.2C506.6 110.1 512 118.6 512 127.1C512 137.3 506.6 145.8 498.1 149.8L279.5 250.8C264.6 257.7 247.4 257.7 232.5 250.8L13.93 149.8C5.438 145.8 0 137.3 0 127.1C0 118.6 5.437 110.1 13.93 106.2L232.5 5.171zM498.1 234.2C506.6 238.1 512 246.6 512 255.1C512 265.3 506.6 273.8 498.1 277.8L279.5 378.8C264.6 385.7 247.4 385.7 232.5 378.8L13.93 277.8C5.438 273.8 0 265.3 0 255.1C0 246.6 5.437 238.1 13.93 234.2L67.13 209.6L219.1 279.8C242.5 290.7 269.5 290.7 292.9 279.8L444.9 209.6L498.1 234.2zM292.9 407.8L444.9 337.6L498.1 362.2C506.6 366.1 512 374.6 512 383.1C512 393.3 506.6 401.8 498.1 405.8L279.5 506.8C264.6 513.7 247.4 513.7 232.5 506.8L13.93 405.8C5.438 401.8 0 393.3 0 383.1C0 374.6 5.437 366.1 13.93 362.2L67.13 337.6L219.1 407.8C242.5 418.7 269.5 418.7 292.9 407.8V407.8z",ie);break;case"UnionAll":o=new s.fabric.Path("M200 288H88c-21.4 0-32.1 25.8-17 41l32.9 31-99.2 99.3c-6.2 6.2-6.2 16.4 0 22.6l25.4 25.4c6.2 6.2 16.4 6.2 22.6 0L152 408l31.1 33c15.1 15.1 40.9 4.4 40.9-17V312c0-13.3-10.7-24-24-24zm112-64h112c21.4 0 32.1-25.9 17-41l-33-31 99.3-99.3c6.2-6.2 6.2-16.4 0-22.6L481.9 4.7c-6.2-6.2-16.4-6.2-22.6 0L360 104l-31.1-33C313.8 55.9 288 66.6 288 88v112c0 13.3 10.7 24 24 24zm96 136l33-31.1c15.1-15.1 4.4-40.9-17-40.9H312c-13.3 0-24 10.7-24 24v112c0 21.4 25.9 32.1 41 17l31-32.9 99.3 99.3c6.2 6.2 16.4 6.2 22.6 0l25.4-25.4c6.2-6.2 6.2-16.4 0-22.6L408 360zM183 71.1L152 104 52.7 4.7c-6.2-6.2-16.4-6.2-22.6 0L4.7 30.1c-6.2 6.2-6.2 16.4 0 22.6L104 152l-33 31.1C55.9 198.2 66.6 224 88 224h112c13.3 0 24-10.7 24-24V88c0-21.3-25.9-32-41-16.9z",ie);break;case"HashShuffle":o=new s.fabric.Path("M504.971 359.029c9.373 9.373 9.373 24.569 0 33.941l-80 79.984c-15.01 15.01-40.971 4.49-40.971-16.971V416h-58.785a12.004 12.004 0 0 1-8.773-3.812l-70.556-75.596 53.333-57.143L352 336h32v-39.981c0-21.438 25.943-31.998 40.971-16.971l80 79.981zM12 176h84l52.781 56.551 53.333-57.143-70.556-75.596A11.999 11.999 0 0 0 122.785 96H12c-6.627 0-12 5.373-12 12v56c0 6.627 5.373 12 12 12zm372 0v39.984c0 21.46 25.961 31.98 40.971 16.971l80-79.984c9.373-9.373 9.373-24.569 0-33.941l-80-79.981C409.943 24.021 384 34.582 384 56.019V96h-58.785a12.004 12.004 0 0 0-8.773 3.812L96 336H12c-6.627 0-12 5.373-12 12v56c0 6.627 5.373 12 12 12h110.785c3.326 0 6.503-1.381 8.773-3.812L352 176h32z",ie);break;case"Map":o=new s.fabric.Path("M256 8c137 0 248 111 248 248S393 504 256 504 8 393 8 256 119 8 256 8zm-28.9 143.6l75.5 72.4H120c-13.3 0-24 10.7-24 24v16c0 13.3 10.7 24 24 24h182.6l-75.5 72.4c-9.7 9.3-9.9 24.8-.4 34.3l11 10.9c9.4 9.4 24.6 9.4 33.9 0L404.3 273c9.4-9.4 9.4-24.6 0-33.9L271.6 106.3c-9.4-9.4-24.6-9.4-33.9 0l-11 10.9c-9.5 9.6-9.3 25.1.4 34.4z",ie);break;case"Broadcast":o=new s.fabric.Path("M377.941 169.941V216H134.059v-46.059c0-21.382-25.851-32.09-40.971-16.971L7.029 239.029c-9.373 9.373-9.373 24.568 0 33.941l86.059 86.059c15.119 15.119 40.971 4.411 40.971-16.971V296h243.882v46.059c0 21.382 25.851 32.09 40.971 16.971l86.059-86.059c9.373-9.373 9.373-24.568 0-33.941l-86.059-86.059c-15.119-15.12-40.971-4.412-40.971 16.97z",ie)}return o&&(o.set({fill:i.getCommonColor("text-misc"),top:0,left:0,originY:"center"}),n.set({left:22}),r.push(o)),new s.fabric.Group(r,Object.assign(Object.assign({},c),{hoverCursor:t?"pointer":"default"}))}class ne{constructor(e,t,i,s,n){this.expanded=!1,this.expandedNodeHeight=0,this.nodeHeight=0,this.canvas=e,this.coords=t,this.treeNode=i,this.opts=s,this.em=n,this.data=Q()(i,["data","data"]),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup(),this.initListeners()}getShape(){return this.group}getFillColor(){return this.opts.colors.getCommonColor("base-misc-light")}getHoverFillColor(){return this.opts.colors.getCommonColor("base-misc-light-hover")}getShadow(){}getHoverShadow(){}toggleHighlight(e){this.isExpandable()&&!this.expanded&&this.body.set({fill:e?this.getHoverFillColor():this.getFillColor()}),this.canvas.requestRenderAll()}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+te.padding,new s.fabric.Rect({width:te.width,height:this.nodeHeight,fill:this.getFillColor(),shadow:this.getShadow(),stroke:e.getCommonColor("line-misc"),rx:te.borderRadius,ry:te.borderRadius,hoverCursor:this.isExpandable()?"pointer":"default"})}prepareShapeObjects(){return[ee(this.data.id,this.isExpandable(),this.opts.colors),se(this.data.name||"",this.isExpandable(),this.opts.colors)]}setShapeObjectsCoords(){const[e,t]=this.objects,i=te.padding,s=this.expanded?te.expandedWidth:te.width,n=t.getScaledWidth();e.set({left:0,top:4,width:s-4}),t.set({left:s/2-n/2,top:i})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},c))}initListeners(){this.initHover(),this.isExpandable()&&this.initExpand()}initHover(){this.group.on("mouseover",(()=>{this.em.dispatch("node:mouseover",this.treeNode),this.toggleHighlight(!0)})),this.group.on("mouseout",(()=>{this.em.dispatch("node:mouseout",this.treeNode),this.toggleHighlight(!1)}))}initExpand(){this.group.on("mousedown",(e=>{var t;this.stats&&(null===(t=e.subTargets)||void 0===t?void 0:t.includes(this.stats))||(this.expanded=!this.expanded,this.updateDimensions(),this.em.dispatch("node:resize",this.treeNode))}))}updateDimensions(){const e=this.opts.colors,[t,i]=this.objects,s=i.getScaledWidth();let n,r;this.expanded?(this.stats=J(this.canvas,this.data.stats,(this.group.top||0)+this.body.getScaledHeight()+te.padding,(this.group.left||0)+te.padding,e),this.expandedNodeHeight=this.nodeHeight+this.stats.getScaledHeight()+2*te.padding,n=te.expandedWidth,r=this.expandedNodeHeight,this.group.addWithUpdate(this.stats)):(n=te.width,r=this.nodeHeight,this.group.removeWithUpdate(this.stats),this.stats=void 0);const o=function(e,t){const i=[];return t.forEachObject((s=>{i.push(s),t.removeWithUpdate(s),e.add(s)})),()=>{i.forEach((i=>{e.remove(i),t.addWithUpdate(i)}))}}(this.canvas,this.group);this.body.set({width:n,height:r,fill:this.getFillColor(),shadow:this.getShadow()}),t.set({width:n-4}),i.set({left:(this.body.left||0)+(this.body.width||0)/2-s/2}),o()}isExpandable(){return Boolean(this.data.stats&&this.data.stats.length>0)}}const re={width:190,bevelSize:10,titleFontSize:h,titleLineHeight:d,padding:12};class oe{constructor(e,t,i,n,r){this.nodeHeight=0,this.coords=t,this.opts=n,this.data=Q()(i,["data","data"]),this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(){}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+re.padding,new s.fabric.Polygon([{x:re.bevelSize,y:0},{x:re.width-re.bevelSize,y:0},{x:re.width,y:re.bevelSize},{x:re.width,y:this.nodeHeight-re.bevelSize},{x:re.width-re.bevelSize,y:this.nodeHeight},{x:re.bevelSize,y:this.nodeHeight},{x:0,y:this.nodeHeight-re.bevelSize},{x:0,y:re.bevelSize}],{fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,shadow:this.getShadow(),hoverCursor:"default"})}prepareShapeObjects(){var e,t;return[(e=[this.data.name||""],t=this.opts.colors,new s.fabric.Text(e.join("\n"),{fontSize:re.titleFontSize,lineHeight:re.titleLineHeight,left:0,top:26,fontFamily:l,fontStyle:"italic",fill:t.getCommonColor("text-primary")}))]}setShapeObjectsCoords(){const[e]=this.objects,t=re.padding,i=e.getScaledWidth();e.set({left:re.width/2-i/2,top:t})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},c))}}const ae=40,ce=40,le=20;class he{constructor(e,t,i,n,r){this.coords=t,this.opts=n,this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.body=this.prepareNodeBody(),this.group=this.createGroup()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(){}prepareNodeBody(){const e=this.opts.colors;return new s.fabric.Rect({width:ae,height:ce,fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,rx:le,ry:le,shadow:this.getShadow(),hoverCursor:"default"})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body],Object.assign({top:e,left:t},c))}}const de={width:112,borderRadius:6,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:12,textOffset:8};class ue{constructor(e,t,i,n,r){this.nodeHeight=0,this.coords=t,this.opts=n,this.data=Q()(i,["data","data"]),this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(){}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+de.padding,new s.fabric.Rect({width:de.width,height:this.nodeHeight,fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,shadow:this.getShadow(),hoverCursor:"default"})}prepareShapeObjects(){var e,t;return[(e=[this.data.name||""],t=this.opts.colors,new s.fabric.Text(e.join("\n"),{fontSize:de.textFontSize,lineHeight:de.textLineHeight,left:0,top:26,fontFamily:l,fill:t.getCommonColor("text-primary")}))]}setShapeObjectsCoords(){const[e]=this.objects,t=de.padding,i=e.getScaledWidth();e.set({left:de.width/2-i/2,top:t})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},c))}}const ge={width:248,expandedWidth:360,borderRadius:6,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:12,textOffset:8};class pe{constructor(e,t,i,n,r){this.expanded=!1,this.expandedNodeHeight=0,this.nodeHeight=0,this.canvas=e,this.coords=t,this.treeNode=i,this.opts=n,this.em=r,this.data=Q()(i,["data","data"]),this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup(),this.initListeners()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(e){this.isExpandable()&&!this.expanded&&this.body.set({fill:e?this.getHoverFillColor():this.getFillColor(),shadow:e?this.getHoverShadow():this.getShadow()}),this.canvas.requestRenderAll()}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+ge.padding,new s.fabric.Rect({width:ge.width,height:this.nodeHeight,fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,rx:ge.borderRadius,ry:ge.borderRadius,shadow:this.getShadow(),hoverCursor:this.isExpandable()?"pointer":"default"})}prepareShapeObjects(){const e=ee(this.data.id,this.isExpandable(),this.opts.colors),t=(i=this.data.operators||[this.data.name||""],n=this.isExpandable(),r=this.opts.colors,new s.fabric.Text(i.join("\n"),{fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:l,fill:r.getCommonColor("text-primary"),hoverCursor:n?"pointer":"default"}));var i,n,r;const o=function(e,t){if(0===e.length)return new s.fabric.Group([],Object.assign({top:0,left:0},c));const i=new s.fabric.Text("Tables:",{fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:l,fill:t.getCommonColor("text-secondary"),hoverCursor:"pointer"}),n=i.getScaledWidth()+2,r=ge.width-2*ge.padding-n,o=new s.fabric.Textbox(e.join("\n"),{left:n,width:r,fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:l,fill:t.getCommonColor("text-primary"),splitByGrapheme:!0,hoverCursor:"pointer"});return new s.fabric.Group([i,o],Object.assign({top:0,left:0},c))}(this.data.tables||[],this.opts.colors),a=function(e,t){if(!e)return new s.fabric.Group([],Object.assign({top:0,left:0},c));const i=new s.fabric.Text("CTE:",{fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:l,fill:t.getCommonColor("text-secondary"),hoverCursor:"pointer"}),n=i.getScaledWidth()+2,r=ge.width-2*ge.padding-n,o=new s.fabric.Textbox(e,{left:n,width:r,fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:l,fill:t.getCommonColor("text-primary"),splitByGrapheme:!0,hoverCursor:"pointer"});return new s.fabric.Group([i,o],Object.assign({top:0,left:0},c))}(this.data.cte||"",this.opts.colors);return[e,t,o,a]}setShapeObjectsCoords(){const[e,t,i,s]=this.objects;let n=ge.padding;const r=ge.padding;e.set({left:0,top:4,width:(this.expanded?ge.expandedWidth:ge.width)-4}),t.set({left:r,top:n}),n+=t.getScaledHeight(),i.set({left:r,top:n+(0===i.size()?0:ge.textOffset)}),n+=i.getScaledHeight(),s.set({left:r,top:n+(0===s.size()?0:ge.textOffset)})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},c))}initListeners(){this.initHover(),this.isExpandable()&&this.initExpand()}initHover(){this.group.on("mouseover",(()=>{this.em.dispatch("node:mouseover",this.treeNode),this.toggleHighlight(!0)})),this.group.on("mouseout",(()=>{this.em.dispatch("node:mouseout",this.treeNode),this.toggleHighlight(!1)}))}initExpand(){this.group.on("mousedown",(e=>{var t;this.stats&&(null===(t=e.subTargets)||void 0===t?void 0:t.includes(this.stats))||(this.updateDimensions(),this.expanded=!this.expanded,this.em.dispatch("node:resize",this.treeNode))}))}updateDimensions(){const e=this.opts.colors;if(this.expanded){const e=ge.width,t=this.nodeHeight;this.body.set({width:e,height:t,fill:this.getFillColor(),shadow:this.getShadow()}).setCoords(),this.objects[0].set({width:e-4}).setCoords(),this.group.removeWithUpdate(this.stats),this.stats=void 0}else{this.stats=J(this.canvas,this.data.stats,(this.group.top||0)+this.body.getScaledHeight()+ge.padding,(this.group.left||0)+ge.padding,e),this.expandedNodeHeight=this.nodeHeight+this.stats.getScaledHeight()+2*ge.padding;const t=ge.expandedWidth,i=this.expandedNodeHeight;this.body.set({width:t,height:i,fill:this.getFillColor(),shadow:this.getShadow()}).setCoords(),this.objects[0].set({width:t-4}).setCoords(),this.group.addWithUpdate(this.stats)}}isExpandable(){return Boolean(this.data.stats&&this.data.stats.length>0)}}function me(e,t,i,s,n){return function(e){const t=Q()(e,["data","data"]);return"connection"===(null===t||void 0===t?void 0:t.type)}(i)?new ne(e,t,i,s,n):function(e){const t=Q()(e,["data","data"]);return"result"===(null===t||void 0===t?void 0:t.type)}(i)?new ue(e,t,i,s,n):function(e){const t=Q()(e,["data","data"]);return"query"===(null===t||void 0===t?void 0:t.type)}(i)?new he(e,t,i,s,n):function(e){const t=Q()(e,["data","data"]);return"materialize"===(null===t||void 0===t?void 0:t.type)}(i)?new oe(e,t,i,s,n):new pe(e,t,i,s,n)}},73374:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"m3",extensions:[".m3",".i3",".mg",".ig"],aliases:["Modula-3","Modula3","modula3","m3"],loader:()=>i.e(79312).then(i.bind(i,79312))})},73401:(e,t,i)=>{"use strict";i.d(t,{GM:()=>h,OA:()=>u,pY:()=>d,tN:()=>g,zk:()=>l});var s=i(64383),n=i(5662),r=i(31308),o=i(83069),a=i(36677);const c=[];function l(){return c}class h{constructor(e,t){if(this.startColumn=e,this.endColumnExclusive=t,e>t)throw new s.D7(`startColumn ${e} cannot be after endColumnExclusive ${t}`)}toRange(e){return new a.Q(e,this.startColumn,e,this.endColumnExclusive)}equals(e){return this.startColumn===e.startColumn&&this.endColumnExclusive===e.endColumnExclusive}}function d(e,t){const i=new n.Cm,s=e.createDecorationsCollection();return i.add((0,r.zL)({debugName:()=>`Apply decorations from ${t.debugName}`},(e=>{const i=t.read(e);s.set(i)}))),i.add({dispose:()=>{s.clear()}}),i}function u(e,t){return new o.y(e.lineNumber+t.lineNumber-1,1===t.lineNumber?e.column+t.column-1:t.column)}function g(e,t){return new o.y(e.lineNumber-t.lineNumber+1,e.lineNumber-t.lineNumber===0?e.column-t.column+1:e.column)}},73823:(e,t,i)=>{"use strict";i.d(t,{G5:()=>n,N8:()=>o,ke:()=>r});var s=i(63591);const n=(0,s.u1)("progressService");Object.freeze({total(){},worked(){},done(){}});class r{static{this.None=Object.freeze({report(){}})}constructor(e){this.callback=e}report(e){this._value=e,this.callback(this._value)}}const o=(0,s.u1)("editorProgressService")},73848:(e,t,i)=>{"use strict";i.r(t),i.d(t,{KeyMod:()=>u,createMonacoBaseAPI:()=>g});var s=i(18447),n=i(41234),r=i(24939),o=i(79400),a=i(83069),c=i(36677),l=i(75326),h=i(62083),d=i(35015);class u{static{this.CtrlCmd=2048}static{this.Shift=1024}static{this.Alt=512}static{this.WinCtrl=256}static chord(e,t){return(0,r.m5)(e,t)}}function g(){return{editor:void 0,languages:void 0,CancellationTokenSource:s.Qi,Emitter:n.vl,KeyCode:d.DD,KeyMod:u,Position:a.y,Range:c.Q,Selection:l.L,SelectionDirection:d.SB,MarkerSeverity:d.cj,MarkerTag:d.d_,Uri:o.r,Token:h.ou}}},73917:(e,t,i)=>{var s=i(79064);e.exports=function(e){return(null==e?0:e.length)?s(e,1):[]}},73983:(e,t,i)=>{"use strict";function s(e){return e&&"object"===typeof e&&"string"===typeof e.original&&"string"===typeof e.value}function n(e){return!!e&&void 0!==e.condition}i.d(t,{N:()=>n,f:()=>s})},74027:(e,t,i)=>{"use strict";i.d(t,{IN:()=>f,LC:()=>R,P8:()=>w,S8:()=>C,SA:()=>v,V8:()=>S,Vn:()=>L,fj:()=>E,hd:()=>b,pD:()=>y});var s=i(59911);const n=46,r=47,o=92,a=58;class c extends Error{constructor(e,t,i){let s;"string"===typeof t&&0===t.indexOf("not ")?(s="must not be",t=t.replace(/^not /,"")):s="must be";const n=-1!==e.indexOf(".")?"property":"argument";let r=`The "${e}" ${n} ${s} of type ${t}`;r+=". Received type "+typeof i,super(r),this.code="ERR_INVALID_ARG_TYPE"}}function l(e,t){if("string"!==typeof e)throw new c(t,"string",e)}const h="win32"===s.iD;function d(e){return e===r||e===o}function u(e){return e===r}function g(e){return e>=65&&e<=90||e>=97&&e<=122}function p(e,t,i,s){let o="",a=0,c=-1,l=0,h=0;for(let d=0;d<=e.length;++d){if(d2){const e=o.lastIndexOf(i);-1===e?(o="",a=0):(o=o.slice(0,e),a=o.length-1-o.lastIndexOf(i)),c=d,l=0;continue}if(0!==o.length){o="",a=0,c=d,l=0;continue}}t&&(o+=o.length>0?`${i}..`:"..",a=2)}else o.length>0?o+=`${i}${e.slice(c+1,d)}`:o=e.slice(c+1,d),a=d-c-1;c=d,l=0}else h===n&&-1!==l?++l:l=-1}return o}function m(e,t){!function(e,t){if(null===e||"object"!==typeof e)throw new c(t,"Object",e)}(t,"pathObject");const i=t.dir||t.root,s=t.base||`${t.name||""}${n=t.ext,n?`${"."===n[0]?"":"."}${n}`:""}`;var n;return i?i===t.root?`${i}${s}`:`${i}${e}${s}`:s}const f={resolve(...e){let t="",i="",n=!1;for(let r=e.length-1;r>=-1;r--){let c;if(r>=0){if(c=e[r],l(c,`paths[${r}]`),0===c.length)continue}else 0===t.length?c=s.bJ():(c={NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}[`=${t}`]||s.bJ(),(void 0===c||c.slice(0,2).toLowerCase()!==t.toLowerCase()&&c.charCodeAt(2)===o)&&(c=`${t}\\`));const h=c.length;let u=0,p="",m=!1;const f=c.charCodeAt(0);if(1===h)d(f)&&(u=1,m=!0);else if(d(f))if(m=!0,d(c.charCodeAt(1))){let e=2,t=e;for(;e2&&d(c.charCodeAt(2))&&(m=!0,u=3));if(p.length>0)if(t.length>0){if(p.toLowerCase()!==t.toLowerCase())continue}else t=p;if(n){if(t.length>0)break}else if(i=`${c.slice(u)}\\${i}`,n=m,m&&t.length>0)break}return i=p(i,!n,"\\",d),n?`${t}\\${i}`:`${t}${i}`||"."},normalize(e){l(e,"path");const t=e.length;if(0===t)return".";let i,s=0,n=!1;const r=e.charCodeAt(0);if(1===t)return u(r)?"\\":e;if(d(r))if(n=!0,d(e.charCodeAt(1))){let n=2,r=n;for(;n2&&d(e.charCodeAt(2))&&(n=!0,s=3));let o=s0&&d(e.charCodeAt(t-1))&&(o+="\\"),void 0===i?n?`\\${o}`:o:n?`${i}\\${o}`:`${i}${o}`},isAbsolute(e){l(e,"path");const t=e.length;if(0===t)return!1;const i=e.charCodeAt(0);return d(i)||t>2&&g(i)&&e.charCodeAt(1)===a&&d(e.charCodeAt(2))},join(...e){if(0===e.length)return".";let t,i;for(let r=0;r0&&(void 0===t?t=i=s:t+=`\\${s}`)}if(void 0===t)return".";let s=!0,n=0;if("string"===typeof i&&d(i.charCodeAt(0))){++n;const e=i.length;e>1&&d(i.charCodeAt(1))&&(++n,e>2&&(d(i.charCodeAt(2))?++n:s=!1))}if(s){for(;n=2&&(t=`\\${t.slice(n)}`)}return f.normalize(t)},relative(e,t){if(l(e,"from"),l(t,"to"),e===t)return"";const i=f.resolve(e),s=f.resolve(t);if(i===s)return"";if((e=i.toLowerCase())===(t=s.toLowerCase()))return"";let n=0;for(;nn&&e.charCodeAt(r-1)===o;)r--;const a=r-n;let c=0;for(;cc&&t.charCodeAt(h-1)===o;)h--;const d=h-c,u=au){if(t.charCodeAt(c+p)===o)return s.slice(c+p+1);if(2===p)return s.slice(c+p)}a>u&&(e.charCodeAt(n+p)===o?g=p:2===p&&(g=3)),-1===g&&(g=0)}let m="";for(p=n+g+1;p<=r;++p)p!==r&&e.charCodeAt(p)!==o||(m+=0===m.length?"..":"\\..");return c+=g,m.length>0?`${m}${s.slice(c,h)}`:(s.charCodeAt(c)===o&&++c,s.slice(c,h))},toNamespacedPath(e){if("string"!==typeof e||0===e.length)return e;const t=f.resolve(e);if(t.length<=2)return e;if(t.charCodeAt(0)===o){if(t.charCodeAt(1)===o){const e=t.charCodeAt(2);if(63!==e&&e!==n)return`\\\\?\\UNC\\${t.slice(2)}`}}else if(g(t.charCodeAt(0))&&t.charCodeAt(1)===a&&t.charCodeAt(2)===o)return`\\\\?\\${t}`;return e},dirname(e){l(e,"path");const t=e.length;if(0===t)return".";let i=-1,s=0;const n=e.charCodeAt(0);if(1===t)return d(n)?e:".";if(d(n)){if(i=s=1,d(e.charCodeAt(1))){let n=2,r=n;for(;n2&&d(e.charCodeAt(2))?3:2,s=i);let r=-1,o=!0;for(let a=t-1;a>=s;--a)if(d(e.charCodeAt(a))){if(!o){r=a;break}}else o=!1;if(-1===r){if(-1===i)return".";r=i}return e.slice(0,r)},basename(e,t){void 0!==t&&l(t,"suffix"),l(e,"path");let i,s=0,n=-1,r=!0;if(e.length>=2&&g(e.charCodeAt(0))&&e.charCodeAt(1)===a&&(s=2),void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let o=t.length-1,a=-1;for(i=e.length-1;i>=s;--i){const c=e.charCodeAt(i);if(d(c)){if(!r){s=i+1;break}}else-1===a&&(r=!1,a=i+1),o>=0&&(c===t.charCodeAt(o)?-1===--o&&(n=i):(o=-1,n=a))}return s===n?n=a:-1===n&&(n=e.length),e.slice(s,n)}for(i=e.length-1;i>=s;--i)if(d(e.charCodeAt(i))){if(!r){s=i+1;break}}else-1===n&&(r=!1,n=i+1);return-1===n?"":e.slice(s,n)},extname(e){l(e,"path");let t=0,i=-1,s=0,r=-1,o=!0,c=0;e.length>=2&&e.charCodeAt(1)===a&&g(e.charCodeAt(0))&&(t=s=2);for(let a=e.length-1;a>=t;--a){const t=e.charCodeAt(a);if(d(t)){if(!o){s=a+1;break}}else-1===r&&(o=!1,r=a+1),t===n?-1===i?i=a:1!==c&&(c=1):-1!==i&&(c=-1)}return-1===i||-1===r||0===c||1===c&&i===r-1&&i===s+1?"":e.slice(i,r)},format:m.bind(null,"\\"),parse(e){l(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const i=e.length;let s=0,r=e.charCodeAt(0);if(1===i)return d(r)?(t.root=t.dir=e,t):(t.base=t.name=e,t);if(d(r)){if(s=1,d(e.charCodeAt(1))){let t=2,n=t;for(;t0&&(t.root=e.slice(0,s));let o=-1,c=s,h=-1,u=!0,p=e.length-1,m=0;for(;p>=s;--p)if(r=e.charCodeAt(p),d(r)){if(!u){c=p+1;break}}else-1===h&&(u=!1,h=p+1),r===n?-1===o?o=p:1!==m&&(m=1):-1!==o&&(m=-1);return-1!==h&&(-1===o||0===m||1===m&&o===h-1&&o===c+1?t.base=t.name=e.slice(c,h):(t.name=e.slice(c,o),t.base=e.slice(c,h),t.ext=e.slice(o,h))),t.dir=c>0&&c!==s?e.slice(0,c-1):t.root,t},sep:"\\",delimiter:";",win32:null,posix:null},_=(()=>{if(h){const e=/\\/g;return()=>{const t=s.bJ().replace(e,"/");return t.slice(t.indexOf("/"))}}return()=>s.bJ()})(),v={resolve(...e){let t="",i=!1;for(let s=e.length-1;s>=-1&&!i;s--){const n=s>=0?e[s]:_();l(n,`paths[${s}]`),0!==n.length&&(t=`${n}/${t}`,i=n.charCodeAt(0)===r)}return t=p(t,!i,"/",u),i?`/${t}`:t.length>0?t:"."},normalize(e){if(l(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===r,i=e.charCodeAt(e.length-1)===r;return 0===(e=p(e,!t,"/",u)).length?t?"/":i?"./":".":(i&&(e+="/"),t?`/${e}`:e)},isAbsolute:e=>(l(e,"path"),e.length>0&&e.charCodeAt(0)===r),join(...e){if(0===e.length)return".";let t;for(let i=0;i0&&(void 0===t?t=s:t+=`/${s}`)}return void 0===t?".":v.normalize(t)},relative(e,t){if(l(e,"from"),l(t,"to"),e===t)return"";if((e=v.resolve(e))===(t=v.resolve(t)))return"";const i=e.length,s=i-1,n=t.length-1,o=so){if(t.charCodeAt(1+c)===r)return t.slice(1+c+1);if(0===c)return t.slice(1+c)}else s>o&&(e.charCodeAt(1+c)===r?a=c:0===c&&(a=0));let h="";for(c=1+a+1;c<=i;++c)c!==i&&e.charCodeAt(c)!==r||(h+=0===h.length?"..":"/..");return`${h}${t.slice(1+a)}`},toNamespacedPath:e=>e,dirname(e){if(l(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===r;let i=-1,s=!0;for(let n=e.length-1;n>=1;--n)if(e.charCodeAt(n)===r){if(!s){i=n;break}}else s=!1;return-1===i?t?"/":".":t&&1===i?"//":e.slice(0,i)},basename(e,t){void 0!==t&&l(t,"ext"),l(e,"path");let i,s=0,n=-1,o=!0;if(void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let a=t.length-1,c=-1;for(i=e.length-1;i>=0;--i){const l=e.charCodeAt(i);if(l===r){if(!o){s=i+1;break}}else-1===c&&(o=!1,c=i+1),a>=0&&(l===t.charCodeAt(a)?-1===--a&&(n=i):(a=-1,n=c))}return s===n?n=c:-1===n&&(n=e.length),e.slice(s,n)}for(i=e.length-1;i>=0;--i)if(e.charCodeAt(i)===r){if(!o){s=i+1;break}}else-1===n&&(o=!1,n=i+1);return-1===n?"":e.slice(s,n)},extname(e){l(e,"path");let t=-1,i=0,s=-1,o=!0,a=0;for(let c=e.length-1;c>=0;--c){const l=e.charCodeAt(c);if(l!==r)-1===s&&(o=!1,s=c+1),l===n?-1===t?t=c:1!==a&&(a=1):-1!==t&&(a=-1);else if(!o){i=c+1;break}}return-1===t||-1===s||0===a||1===a&&t===s-1&&t===i+1?"":e.slice(t,s)},format:m.bind(null,"/"),parse(e){l(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const i=e.charCodeAt(0)===r;let s;i?(t.root="/",s=1):s=0;let o=-1,a=0,c=-1,h=!0,d=e.length-1,u=0;for(;d>=s;--d){const t=e.charCodeAt(d);if(t!==r)-1===c&&(h=!1,c=d+1),t===n?-1===o?o=d:1!==u&&(u=1):-1!==o&&(u=-1);else if(!h){a=d+1;break}}if(-1!==c){const s=0===a&&i?1:a;-1===o||0===u||1===u&&o===c-1&&o===a+1?t.base=t.name=e.slice(s,c):(t.name=e.slice(s,o),t.base=e.slice(s,c),t.ext=e.slice(o,c))}return a>0?t.dir=e.slice(0,a-1):i&&(t.dir="/"),t},sep:"/",delimiter:":",win32:null,posix:null};v.win32=f.win32=f,v.posix=f.posix=v;const C=h?f.normalize:v.normalize,E=h?f.join:v.join,b=h?f.resolve:v.resolve,S=h?f.relative:v.relative,y=h?f.dirname:v.dirname,w=h?f.basename:v.basename,R=h?f.extname:v.extname,L=h?f.sep:v.sep},74196:(e,t,i)=>{"use strict";i.d(t,{YJ:()=>c,_8:()=>a});var s=i(98067),n=i(87908),r=i(79027);const o=s.zx?1.5:1.35;class a{static createFromValidatedSettings(e,t,i){const s=e.get(49),n=e.get(53),r=e.get(52),o=e.get(51),c=e.get(54),l=e.get(67),h=e.get(64);return a._create(s,n,r,o,c,l,h,t,i)}static _create(e,t,i,s,c,l,h,d,u){0===l?l=o*i:l<8&&(l*=i),(l=Math.round(l))<8&&(l=8);const g=1+(u?0:.1*r.D.getZoomLevel());if(i*=g,l*=g,c===n.r_.TRANSLATE)if("normal"===t||"bold"===t)c=n.r_.OFF;else{c=`'wght' ${parseInt(t,10)}`,t="normal"}return new a({pixelRatio:d,fontFamily:e,fontWeight:t,fontSize:i,fontFeatureSettings:s,fontVariationSettings:c,lineHeight:l,letterSpacing:h})}constructor(e){this._bareFontInfoBrand=void 0,this.pixelRatio=e.pixelRatio,this.fontFamily=String(e.fontFamily),this.fontWeight=String(e.fontWeight),this.fontSize=e.fontSize,this.fontFeatureSettings=e.fontFeatureSettings,this.fontVariationSettings=e.fontVariationSettings,this.lineHeight=0|e.lineHeight,this.letterSpacing=e.letterSpacing}getId(){return`${this.pixelRatio}-${this.fontFamily}-${this.fontWeight}-${this.fontSize}-${this.fontFeatureSettings}-${this.fontVariationSettings}-${this.lineHeight}-${this.letterSpacing}`}getMassagedFontFamily(){const e=n.jU.fontFamily,t=a._wrapInQuotes(this.fontFamily);return e&&this.fontFamily!==e?`${t}, ${e}`:t}static _wrapInQuotes(e){return/[,"']/.test(e)?e:/[+ ]/.test(e)?`"${e}"`:e}}class c extends a{constructor(e,t){super(e),this._editorStylingBrand=void 0,this.version=2,this.isTrusted=t,this.isMonospace=e.isMonospace,this.typicalHalfwidthCharacterWidth=e.typicalHalfwidthCharacterWidth,this.typicalFullwidthCharacterWidth=e.typicalFullwidthCharacterWidth,this.canUseHalfwidthRightwardsArrow=e.canUseHalfwidthRightwardsArrow,this.spaceWidth=e.spaceWidth,this.middotWidth=e.middotWidth,this.wsmiddotWidth=e.wsmiddotWidth,this.maxDigitWidth=e.maxDigitWidth}equals(e){return this.fontFamily===e.fontFamily&&this.fontWeight===e.fontWeight&&this.fontSize===e.fontSize&&this.fontFeatureSettings===e.fontFeatureSettings&&this.fontVariationSettings===e.fontVariationSettings&&this.lineHeight===e.lineHeight&&this.letterSpacing===e.letterSpacing&&this.typicalHalfwidthCharacterWidth===e.typicalHalfwidthCharacterWidth&&this.typicalFullwidthCharacterWidth===e.typicalFullwidthCharacterWidth&&this.canUseHalfwidthRightwardsArrow===e.canUseHalfwidthRightwardsArrow&&this.spaceWidth===e.spaceWidth&&this.middotWidth===e.middotWidth&&this.wsmiddotWidth===e.wsmiddotWidth&&this.maxDigitWidth===e.maxDigitWidth}}},74243:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ISemanticTokensStylingService:()=>s});const s=(0,i(63591).u1)("semanticTokensStylingService")},74276:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"pug",extensions:[".jade",".pug"],aliases:["Pug","Jade","jade"],loader:()=>i.e(29394).then(i.bind(i,29394))})},74304:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"flow9",extensions:[".flow"],aliases:["Flow9","Flow","flow9","flow"],loader:()=>i.e(32854).then(i.bind(i,32854))})},74320:(e,t,i)=>{"use strict";var s,n;i.d(t,{cO:()=>h,db:()=>d,fT:()=>o,qK:()=>l});class r{constructor(e,t){this.uri=e,this.value=t}}class o{static{this.defaultToKey=e=>e.toString()}constructor(e,t){if(this[s]="ResourceMap",e instanceof o)this.map=new Map(e.map),this.toKey=t??o.defaultToKey;else if(function(e){return Array.isArray(e)}(e)){this.map=new Map,this.toKey=t??o.defaultToKey;for(const[t,i]of e)this.set(t,i)}else this.map=new Map,this.toKey=e??o.defaultToKey}set(e,t){return this.map.set(this.toKey(e),new r(e,t)),this}get(e){return this.map.get(this.toKey(e))?.value}has(e){return this.map.has(this.toKey(e))}get size(){return this.map.size}clear(){this.map.clear()}delete(e){return this.map.delete(this.toKey(e))}forEach(e,t){"undefined"!==typeof t&&(e=e.bind(t));for(const[i,s]of this.map)e(s.value,s.uri,this)}*values(){for(const e of this.map.values())yield e.value}*keys(){for(const e of this.map.values())yield e.uri}*entries(){for(const e of this.map.values())yield[e.uri,e.value]}*[(s=Symbol.toStringTag,Symbol.iterator)](){for(const[,e]of this.map)yield[e.uri,e.value]}}class a{constructor(){this[n]="LinkedMap",this._map=new Map,this._head=void 0,this._tail=void 0,this._size=0,this._state=0}clear(){this._map.clear(),this._head=void 0,this._tail=void 0,this._size=0,this._state++}isEmpty(){return!this._head&&!this._tail}get size(){return this._size}get first(){return this._head?.value}get last(){return this._tail?.value}has(e){return this._map.has(e)}get(e,t=0){const i=this._map.get(e);if(i)return 0!==t&&this.touch(i,t),i.value}set(e,t,i=0){let s=this._map.get(e);if(s)s.value=t,0!==i&&this.touch(s,i);else{switch(s={key:e,value:t,next:void 0,previous:void 0},i){case 0:case 2:default:this.addItemLast(s);break;case 1:this.addItemFirst(s)}this._map.set(e,s),this._size++}return this}delete(e){return!!this.remove(e)}remove(e){const t=this._map.get(e);if(t)return this._map.delete(e),this.removeItem(t),this._size--,t.value}shift(){if(!this._head&&!this._tail)return;if(!this._head||!this._tail)throw new Error("Invalid list");const e=this._head;return this._map.delete(e.key),this.removeItem(e),this._size--,e.value}forEach(e,t){const i=this._state;let s=this._head;for(;s;){if(t?e.bind(t)(s.value,s.key,this):e(s.value,s.key,this),this._state!==i)throw new Error("LinkedMap got modified during iteration.");s=s.next}}keys(){const e=this,t=this._state;let i=this._head;const s={[Symbol.iterator]:()=>s,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(i){const e={value:i.key,done:!1};return i=i.next,e}return{value:void 0,done:!0}}};return s}values(){const e=this,t=this._state;let i=this._head;const s={[Symbol.iterator]:()=>s,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(i){const e={value:i.value,done:!1};return i=i.next,e}return{value:void 0,done:!0}}};return s}entries(){const e=this,t=this._state;let i=this._head;const s={[Symbol.iterator]:()=>s,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(i){const e={value:[i.key,i.value],done:!1};return i=i.next,e}return{value:void 0,done:!0}}};return s}[(n=Symbol.toStringTag,Symbol.iterator)](){return this.entries()}trimOld(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._head,i=this.size;for(;t&&i>e;)this._map.delete(t.key),t=t.next,i--;this._head=t,this._size=i,t&&(t.previous=void 0),this._state++}trimNew(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._tail,i=this.size;for(;t&&i>e;)this._map.delete(t.key),t=t.previous,i--;this._tail=t,this._size=i,t&&(t.next=void 0),this._state++}addItemFirst(e){if(this._head||this._tail){if(!this._head)throw new Error("Invalid list");e.next=this._head,this._head.previous=e}else this._tail=e;this._head=e,this._state++}addItemLast(e){if(this._head||this._tail){if(!this._tail)throw new Error("Invalid list");e.previous=this._tail,this._tail.next=e}else this._head=e;this._tail=e,this._state++}removeItem(e){if(e===this._head&&e===this._tail)this._head=void 0,this._tail=void 0;else if(e===this._head){if(!e.next)throw new Error("Invalid list");e.next.previous=void 0,this._head=e.next}else if(e===this._tail){if(!e.previous)throw new Error("Invalid list");e.previous.next=void 0,this._tail=e.previous}else{const t=e.next,i=e.previous;if(!t||!i)throw new Error("Invalid list");t.previous=i,i.next=t}e.next=void 0,e.previous=void 0,this._state++}touch(e,t){if(!this._head||!this._tail)throw new Error("Invalid list");if(1===t||2===t)if(1===t){if(e===this._head)return;const t=e.next,i=e.previous;e===this._tail?(i.next=void 0,this._tail=i):(t.previous=i,i.next=t),e.previous=void 0,e.next=this._head,this._head.previous=e,this._head=e,this._state++}else if(2===t){if(e===this._tail)return;const t=e.next,i=e.previous;e===this._head?(t.previous=void 0,this._head=t):(t.previous=i,i.next=t),e.next=void 0,e.previous=this._tail,this._tail.next=e,this._tail=e,this._state++}}toJSON(){const e=[];return this.forEach(((t,i)=>{e.push([i,t])})),e}fromJSON(e){this.clear();for(const[t,i]of e)this.set(t,i)}}class c extends a{constructor(e,t=1){super(),this._limit=e,this._ratio=Math.min(Math.max(0,t),1)}get limit(){return this._limit}set limit(e){this._limit=e,this.checkTrim()}get(e,t=2){return super.get(e,t)}peek(e){return super.get(e,0)}set(e,t){return super.set(e,t,2),this}checkTrim(){this.size>this._limit&&this.trim(Math.round(this._limit*this._ratio))}}class l extends c{constructor(e,t=1){super(e,t)}trim(e){this.trimOld(e)}set(e,t){return super.set(e,t),this.checkTrim(),this}}class h{constructor(e){if(this._m1=new Map,this._m2=new Map,e)for(const[t,i]of e)this.set(t,i)}clear(){this._m1.clear(),this._m2.clear()}set(e,t){this._m1.set(e,t),this._m2.set(t,e)}get(e){return this._m1.get(e)}getKey(e){return this._m2.get(e)}delete(e){const t=this._m1.get(e);return void 0!==t&&(this._m1.delete(e),this._m2.delete(t),!0)}keys(){return this._m1.keys()}values(){return this._m1.values()}}class d{constructor(){this.map=new Map}add(e,t){let i=this.map.get(e);i||(i=new Set,this.map.set(e,i)),i.add(t)}delete(e,t){const i=this.map.get(e);i&&(i.delete(t),0===i.size&&this.map.delete(e))}forEach(e,t){const i=this.map.get(e);i&&i.forEach(t)}get(e){const t=this.map.get(e);return t||new Set}}},74444:(e,t,i)=>{"use strict";i.d(t,{L:()=>n,h:()=>r});var s=i(64383);class n{static addRange(e,t){let i=0;for(;it))return new n(e,t)}static ofLength(e){return new n(0,e)}static ofStartAndLength(e,t){return new n(e,e+t)}constructor(e,t){if(this.start=e,this.endExclusive=t,e>t)throw new s.D7(`Invalid range: ${this.toString()}`)}get isEmpty(){return this.start===this.endExclusive}delta(e){return new n(this.start+e,this.endExclusive+e)}deltaStart(e){return new n(this.start+e,this.endExclusive)}deltaEnd(e){return new n(this.start,this.endExclusive+e)}get length(){return this.endExclusive-this.start}toString(){return`[${this.start}, ${this.endExclusive})`}contains(e){return this.start<=e&&e=e.endExclusive}slice(e){return e.slice(this.start,this.endExclusive)}substring(e){return e.substring(this.start,this.endExclusive)}clip(e){if(this.isEmpty)throw new s.D7(`Invalid clipping range: ${this.toString()}`);return Math.max(this.start,Math.min(this.endExclusive-1,e))}clipCyclic(e){if(this.isEmpty)throw new s.D7(`Invalid clipping range: ${this.toString()}`);return e=this.endExclusive?this.start+(e-this.start)%this.length:e}forEach(e){for(let t=this.start;te.toString())).join(", ")}intersectsStrict(e){let t=0;for(;te+t.length),0)}}},74688:(e,t,i)=>{e.exports=i(57233)},74800:(e,t,i)=>{"use strict";var s=i(34918);(0,s.K)({id:"freemarker2",extensions:[".ftl",".ftlh",".ftlx"],aliases:["FreeMarker2","Apache FreeMarker2"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagAutoInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-angle.interpolation-dollar",aliases:["FreeMarker2 (Angle/Dollar)","Apache FreeMarker2 (Angle/Dollar)"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagAngleInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-bracket.interpolation-dollar",aliases:["FreeMarker2 (Bracket/Dollar)","Apache FreeMarker2 (Bracket/Dollar)"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagBracketInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-angle.interpolation-bracket",aliases:["FreeMarker2 (Angle/Bracket)","Apache FreeMarker2 (Angle/Bracket)"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagAngleInterpolationBracket))}),(0,s.K)({id:"freemarker2.tag-bracket.interpolation-bracket",aliases:["FreeMarker2 (Bracket/Bracket)","Apache FreeMarker2 (Bracket/Bracket)"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagBracketInterpolationBracket))}),(0,s.K)({id:"freemarker2.tag-auto.interpolation-dollar",aliases:["FreeMarker2 (Auto/Dollar)","Apache FreeMarker2 (Auto/Dollar)"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagAutoInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-auto.interpolation-bracket",aliases:["FreeMarker2 (Auto/Bracket)","Apache FreeMarker2 (Auto/Bracket)"],loader:()=>i.e(90118).then(i.bind(i,90118)).then((e=>e.TagAutoInterpolationBracket))})},74850:(e,t,i)=>{"use strict";i.d(t,{m:()=>s});class s{constructor(e,t,i,s,n,r){this._scrollbarSize=Math.round(t),this._oppositeScrollbarSize=Math.round(i),this._arrowSize=Math.round(e),this._visibleSize=s,this._scrollSize=n,this._scrollPosition=r,this._computedAvailableSize=0,this._computedIsNeeded=!1,this._computedSliderSize=0,this._computedSliderRatio=0,this._computedSliderPosition=0,this._refreshComputedValues()}clone(){return new s(this._arrowSize,this._scrollbarSize,this._oppositeScrollbarSize,this._visibleSize,this._scrollSize,this._scrollPosition)}setVisibleSize(e){const t=Math.round(e);return this._visibleSize!==t&&(this._visibleSize=t,this._refreshComputedValues(),!0)}setScrollSize(e){const t=Math.round(e);return this._scrollSize!==t&&(this._scrollSize=t,this._refreshComputedValues(),!0)}setScrollPosition(e){const t=Math.round(e);return this._scrollPosition!==t&&(this._scrollPosition=t,this._refreshComputedValues(),!0)}setScrollbarSize(e){this._scrollbarSize=Math.round(e)}setOppositeScrollbarSize(e){this._oppositeScrollbarSize=Math.round(e)}static _computeValues(e,t,i,s,n){const r=Math.max(0,i-e),o=Math.max(0,r-2*t),a=s>0&&s>i;if(!a)return{computedAvailableSize:Math.round(r),computedIsNeeded:a,computedSliderSize:Math.round(o),computedSliderRatio:0,computedSliderPosition:0};const c=Math.round(Math.max(20,Math.floor(i*o/s))),l=(o-c)/(s-i),h=n*l;return{computedAvailableSize:Math.round(r),computedIsNeeded:a,computedSliderSize:Math.round(c),computedSliderRatio:l,computedSliderPosition:Math.round(h)}}_refreshComputedValues(){const e=s._computeValues(this._oppositeScrollbarSize,this._arrowSize,this._visibleSize,this._scrollSize,this._scrollPosition);this._computedAvailableSize=e.computedAvailableSize,this._computedIsNeeded=e.computedIsNeeded,this._computedSliderSize=e.computedSliderSize,this._computedSliderRatio=e.computedSliderRatio,this._computedSliderPosition=e.computedSliderPosition}getArrowSize(){return this._arrowSize}getScrollPosition(){return this._scrollPosition}getRectangleLargeSize(){return this._computedAvailableSize}getRectangleSmallSize(){return this._scrollbarSize}isNeeded(){return this._computedIsNeeded}getSliderSize(){return this._computedSliderSize}getSliderPosition(){return this._computedSliderPosition}getDesiredScrollPositionFromOffset(e){if(!this._computedIsNeeded)return 0;const t=e-this._arrowSize-this._computedSliderSize/2;return Math.round(t/this._computedSliderRatio)}getDesiredScrollPositionFromOffsetPaged(e){if(!this._computedIsNeeded)return 0;const t=e-this._arrowSize;let i=this._scrollPosition;return t{"use strict";i.r(t),i.d(t,{UnicodeTextModelHighlighter:()=>c});var s=i(36677),n=i(43264),r=i(91508),o=i(66782),a=i(26486);class c{static computeUnicodeHighlights(e,t,i){const c=i?i.startLineNumber:1,h=i?i.endLineNumber:e.getLineCount(),d=new l(t),u=d.getCandidateCodePoints();let g;var p;g="allNonBasicAscii"===u?new RegExp("[^\\t\\n\\r\\x20-\\x7E]","g"):new RegExp(""+(p=Array.from(u),`[${r.bm(p.map((e=>String.fromCodePoint(e))).join(""))}]`),"g");const m=new n.W5(null,g),f=[];let _,v=!1,C=0,E=0,b=0;e:for(let n=c,l=h;n<=l;n++){const t=e.getLineContent(n),i=t.length;m.reset(0);do{if(_=m.next(t),_){let e=_.index,c=_.index+_[0].length;if(e>0){const i=t.charCodeAt(e-1);r.pc(i)&&e--}if(c+1=t){v=!0;break e}f.push(new s.Q(n,e+1,n,c+1))}}}while(_)}return{ranges:f,hasMore:v,ambiguousCharacterCount:C,invisibleCharacterCount:E,nonBasicAsciiCharacterCount:b}}static computeUnicodeHighlightReason(e,t){const i=new l(t);switch(i.shouldHighlightNonBasicASCII(e,null)){case 0:return null;case 2:return{kind:1};case 3:{const s=e.codePointAt(0),n=i.ambiguousCharacters.getPrimaryConfusable(s),o=r.tl.getLocales().filter((e=>!r.tl.getInstance(new Set([...t.allowedLocales,e])).isAmbiguous(s)));return{kind:0,confusableWith:String.fromCodePoint(n),notAmbiguousInLocales:o}}case 1:return{kind:2}}}}class l{constructor(e){this.options=e,this.allowedCodePoints=new Set(e.allowedCodePoints),this.ambiguousCharacters=r.tl.getInstance(new Set(e.allowedLocales))}getCandidateCodePoints(){if(this.options.nonBasicASCII)return"allNonBasicAscii";const e=new Set;if(this.options.invisibleCharacters)for(const t of r.y_.codePoints)h(String.fromCodePoint(t))||e.add(t);if(this.options.ambiguousCharacters)for(const t of this.ambiguousCharacters.getConfusableCodePoints())e.add(t);for(const t of this.allowedCodePoints)e.delete(t);return e}shouldHighlightNonBasicASCII(e,t){const i=e.codePointAt(0);if(this.allowedCodePoints.has(i))return 0;if(this.options.nonBasicASCII)return 1;let s=!1,n=!1;if(t)for(const o of t){const e=o.codePointAt(0),t=r.aC(o);s=s||t,t||this.ambiguousCharacters.isAmbiguous(e)||r.y_.isInvisibleCharacter(e)||(n=!0)}return!s&&n?0:this.options.invisibleCharacters&&!h(e)&&r.y_.isInvisibleCharacter(i)?2:this.options.ambiguousCharacters&&this.ambiguousCharacters.isAmbiguous(i)?3:0}}function h(e){return" "===e||"\n"===e||"\t"===e}},75147:(e,t,i)=>{"use strict";i.d(t,{DR:()=>c,cj:()=>s,oc:()=>n});var s,n,r=i(42291),o=i(78209),a=i(63591);!function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(s||(s={})),function(e){e.compare=function(e,t){return t-e};const t=Object.create(null);t[e.Error]=(0,o.kg)("sev.error","Error"),t[e.Warning]=(0,o.kg)("sev.warning","Warning"),t[e.Info]=(0,o.kg)("sev.info","Info"),e.toString=function(e){return t[e]||""},e.fromSeverity=function(t){switch(t){case r.A.Error:return e.Error;case r.A.Warning:return e.Warning;case r.A.Info:return e.Info;case r.A.Ignore:return e.Hint}},e.toSeverity=function(t){switch(t){case e.Error:return r.A.Error;case e.Warning:return r.A.Warning;case e.Info:return r.A.Info;case e.Hint:return r.A.Ignore}}}(s||(s={})),function(e){const t="";function i(e,i){const n=[t];return e.source?n.push(e.source.replace("\xa6","\\\xa6")):n.push(t),e.code?"string"===typeof e.code?n.push(e.code.replace("\xa6","\\\xa6")):n.push(e.code.value.replace("\xa6","\\\xa6")):n.push(t),void 0!==e.severity&&null!==e.severity?n.push(s.toString(e.severity)):n.push(t),e.message&&i?n.push(e.message.replace("\xa6","\\\xa6")):n.push(t),void 0!==e.startLineNumber&&null!==e.startLineNumber?n.push(e.startLineNumber.toString()):n.push(t),void 0!==e.startColumn&&null!==e.startColumn?n.push(e.startColumn.toString()):n.push(t),void 0!==e.endLineNumber&&null!==e.endLineNumber?n.push(e.endLineNumber.toString()):n.push(t),void 0!==e.endColumn&&null!==e.endColumn?n.push(e.endColumn.toString()):n.push(t),n.push(t),n.join("\xa6")}e.makeKey=function(e){return i(e,!0)},e.makeKeyOptionalMessage=i}(n||(n={}));const c=(0,a.u1)("markerService")},75162:(e,t,i)=>{e.exports=function(){const e=i(94297);function t(t){try{const i=BigInt(t.$value),s=BigInt(1e3),n=i%s,r=new Date(Number(i/s)),o=r.getFullYear();return o<=0&&r.setFullYear(o-1),r.toISOString().replace("Z","")+function(t){const i=String(t);return e.repeatChar("0",3-i.length)+i}(n)+"Z"}catch(i){return"Invalid timestamp"}}return t.isScalar=!0,t}},75208:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"bicep",extensions:[".bicep"],aliases:["Bicep"],loader:()=>i.e(98014).then(i.bind(i,98014))})},75295:(e,t,i)=>{"use strict";i.d(t,{CO:()=>g,WR:()=>d,mF:()=>h});var s=i(66782),n=i(64383),r=i(83069),o=i(74444),a=i(50973);class c{constructor(e){this.text=e,this.lineStartOffsetByLineIdx=[],this.lineStartOffsetByLineIdx.push(0);for(let t=0;t(0,s.Xo)(e,((e,t)=>e.range.getEndPosition().isBeforeOrEqual(t.range.getStartPosition())))))}apply(e){let t="",i=new r.y(1,1);for(const n of this.edits){const s=n.range,r=s.getStartPosition(),o=s.getEndPosition(),a=u(i,r);a.isEmpty()||(t+=e.getValueOfRange(a)),t+=n.text,i=o}const s=u(i,e.endPositionExclusive);return s.isEmpty()||(t+=e.getValueOfRange(s)),t}applyToString(e){const t=new p(e);return this.apply(t)}getNewRanges(){const e=[];let t=0,i=0,s=0;for(const n of this.edits){const o=a.W.ofText(n.text),c=r.y.lift({lineNumber:n.range.startLineNumber+i,column:n.range.startColumn+(n.range.startLineNumber===t?s:0)}),l=o.createRange(c);e.push(l),i=l.endLineNumber-n.range.endLineNumber,s=l.endColumn-n.range.endColumn,t=n.range.endLineNumber}return e}}class d{constructor(e,t){this.range=e,this.text=t}toSingleEditOperation(){return{range:this.range,text:this.text}}}function u(e,t){if(e.lineNumber===t.lineNumber&&e.column===Number.MAX_SAFE_INTEGER)return l.Q.fromPositions(t,t);if(!e.isBeforeOrEqual(t))throw new n.D7("start must be before end");return new l.Q(e.lineNumber,e.column,t.lineNumber,t.column)}class g{get endPositionExclusive(){return this.length.addToPosition(new r.y(1,1))}}class p extends g{constructor(e){super(),this.value=e,this._t=new c(this.value)}getValueOfRange(e){return this._t.getOffsetRange(e).substring(this.value)}get length(){return this._t.textLength}}},75326:(e,t,i)=>{"use strict";i.d(t,{L:()=>r});var s=i(83069),n=i(36677);class r extends n.Q{constructor(e,t,i,s){super(e,t,i,s),this.selectionStartLineNumber=e,this.selectionStartColumn=t,this.positionLineNumber=i,this.positionColumn=s}toString(){return"["+this.selectionStartLineNumber+","+this.selectionStartColumn+" -> "+this.positionLineNumber+","+this.positionColumn+"]"}equalsSelection(e){return r.selectionsEqual(this,e)}static selectionsEqual(e,t){return e.selectionStartLineNumber===t.selectionStartLineNumber&&e.selectionStartColumn===t.selectionStartColumn&&e.positionLineNumber===t.positionLineNumber&&e.positionColumn===t.positionColumn}getDirection(){return this.selectionStartLineNumber===this.startLineNumber&&this.selectionStartColumn===this.startColumn?0:1}setEndPosition(e,t){return 0===this.getDirection()?new r(this.startLineNumber,this.startColumn,e,t):new r(e,t,this.startLineNumber,this.startColumn)}getPosition(){return new s.y(this.positionLineNumber,this.positionColumn)}getSelectionStart(){return new s.y(this.selectionStartLineNumber,this.selectionStartColumn)}setStartPosition(e,t){return 0===this.getDirection()?new r(e,t,this.endLineNumber,this.endColumn):new r(this.endLineNumber,this.endColumn,e,t)}static fromPositions(e,t=e){return new r(e.lineNumber,e.column,t.lineNumber,t.column)}static fromRange(e,t){return 0===t?new r(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):new r(e.endLineNumber,e.endColumn,e.startLineNumber,e.startColumn)}static liftSelection(e){return new r(e.selectionStartLineNumber,e.selectionStartColumn,e.positionLineNumber,e.positionColumn)}static selectionsArrEqual(e,t){if(e&&!t||!e&&t)return!1;if(!e&&!t)return!0;if(e.length!==t.length)return!1;for(let i=0,s=e.length;i{"use strict";var s=i(24939),n=i(36999),r=i(31450),o=i(15092),a=i(91508),c=i(7085),l=i(36677);class h{constructor(e,t,i){this._selection=e,this._cursors=t,this._selectionId=null,this._trimInRegexesAndStrings=i}getEditOperations(e,t){const i=function(e,t,i){t.sort(((e,t)=>e.lineNumber===t.lineNumber?e.column-t.column:e.lineNumber-t.lineNumber));for(let a=t.length-2;a>=0;a--)t[a].lineNumber===t[a+1].lineNumber&&t.splice(a,1);const s=[];let n=0,r=0;const o=t.length;for(let h=1,d=e.getLineCount();h<=d;h++){const d=e.getLineContent(h),u=d.length+1;let g=0;if(r=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},w=function(e,t){return function(i,s){t(i,s,e)}};let R=class{constructor(e,t,i,s){this._languageConfigurationService=s,this._selection=e,this._isMovingDown=t,this._autoIndent=i,this._selectionId=null,this._moveEndLineSelectionShrink=!1}getEditOperations(e,t){const i=()=>e.getLanguageId(),s=(t,i)=>e.getLanguageIdAtPosition(t,i),n=e.getLineCount();if(this._isMovingDown&&this._selection.endLineNumber===n)return void(this._selectionId=t.trackSelection(this._selection));if(!this._isMovingDown&&1===this._selection.startLineNumber)return void(this._selectionId=t.trackSelection(this._selection));this._moveEndPositionDown=!1;let r=this._selection;r.startLineNumbert===r.startLineNumber?e.tokenization.getLineTokens(n):e.tokenization.getLineTokens(t),getLanguageId:i,getLanguageIdAtPosition:s},getLineContent:t=>t===r.startLineNumber?e.getLineContent(n):e.getLineContent(t)},l=(0,b.$f)(this._autoIndent,t,e.getLanguageIdAtPosition(n,1),r.startLineNumber,d,this._languageConfigurationService);if(null!==l){const t=a.UU(e.getLineContent(n)),i=E.c(l,o);if(i!==E.c(t,o)){const e=E.k(i,o,h);u=e+this.trimStart(c)}}}t.addEditOperation(new l.Q(r.startLineNumber,1,r.startLineNumber,1),u+"\n");const p=this.matchEnterRuleMovingDown(e,d,o,r.startLineNumber,n,u);if(null!==p)0!==p&&this.getIndentEditsOfMovingBlock(e,t,r,o,h,p);else{const c={tokenization:{getLineTokens:t=>t===r.startLineNumber?e.tokenization.getLineTokens(n):t>=r.startLineNumber+1&&t<=r.endLineNumber+1?e.tokenization.getLineTokens(t-1):e.tokenization.getLineTokens(t),getLanguageId:i,getLanguageIdAtPosition:s},getLineContent:t=>t===r.startLineNumber?u:t>=r.startLineNumber+1&&t<=r.endLineNumber+1?e.getLineContent(t-1):e.getLineContent(t)},l=(0,b.$f)(this._autoIndent,c,e.getLanguageIdAtPosition(n,1),r.startLineNumber+1,d,this._languageConfigurationService);if(null!==l){const i=a.UU(e.getLineContent(r.startLineNumber)),s=E.c(l,o),n=E.c(i,o);if(s!==n){const i=s-n;this.getIndentEditsOfMovingBlock(e,t,r,o,h,i)}}}}else t.addEditOperation(new l.Q(r.startLineNumber,1,r.startLineNumber,1),u+"\n")}else if(n=r.startLineNumber-1,c=e.getLineContent(n),t.addEditOperation(new l.Q(n,1,n+1,1),null),t.addEditOperation(new l.Q(r.endLineNumber,e.getLineMaxColumn(r.endLineNumber),r.endLineNumber,e.getLineMaxColumn(r.endLineNumber)),"\n"+c),this.shouldAutoIndent(e,r)){const c={tokenization:{getLineTokens:t=>t===n?e.tokenization.getLineTokens(r.startLineNumber):e.tokenization.getLineTokens(t),getLanguageId:i,getLanguageIdAtPosition:s},getLineContent:t=>t===n?e.getLineContent(r.startLineNumber):e.getLineContent(t)},l=this.matchEnterRule(e,d,o,r.startLineNumber,r.startLineNumber-2);if(null!==l)0!==l&&this.getIndentEditsOfMovingBlock(e,t,r,o,h,l);else{const i=(0,b.$f)(this._autoIndent,c,e.getLanguageIdAtPosition(r.startLineNumber,1),n,d,this._languageConfigurationService);if(null!==i){const s=a.UU(e.getLineContent(r.startLineNumber)),n=E.c(i,o),c=E.c(s,o);if(n!==c){const i=n-c;this.getIndentEditsOfMovingBlock(e,t,r,o,h,i)}}}}}this._selectionId=t.trackSelection(r)}buildIndentConverter(e,t,i){return{shiftIndent:s=>_.Y.shiftIndent(s,s.length+1,e,t,i),unshiftIndent:s=>_.Y.unshiftIndent(s,s.length+1,e,t,i)}}parseEnterResult(e,t,i,s,n){if(n){let r=n.indentation;n.indentAction===v.l.None||n.indentAction===v.l.Indent?r=n.indentation+n.appendText:n.indentAction===v.l.IndentOutdent?r=n.indentation:n.indentAction===v.l.Outdent&&(r=t.unshiftIndent(n.indentation)+n.appendText);const o=e.getLineContent(s);if(this.trimStart(o).indexOf(this.trimStart(r))>=0){const n=a.UU(e.getLineContent(s));let o=a.UU(r);const c=(0,b.Yb)(e,s,this._languageConfigurationService);null!==c&&2&c&&(o=t.unshiftIndent(o));return E.c(o,i)-E.c(n,i)}}return null}matchEnterRuleMovingDown(e,t,i,s,n,r){if(a.lT(r)>=0){const r=e.getLineMaxColumn(n),o=(0,S.h)(this._autoIndent,e,new l.Q(n,r,n,r),this._languageConfigurationService);return this.parseEnterResult(e,t,i,s,o)}{let n=s-1;for(;n>=1;){const t=e.getLineContent(n);if(a.lT(t)>=0)break;n--}if(n<1||s>e.getLineCount())return null;const r=e.getLineMaxColumn(n),o=(0,S.h)(this._autoIndent,e,new l.Q(n,r,n,r),this._languageConfigurationService);return this.parseEnterResult(e,t,i,s,o)}}matchEnterRule(e,t,i,s,n,r){let o=n;for(;o>=1;){let t;t=o===n&&void 0!==r?r:e.getLineContent(o);if(a.lT(t)>=0)break;o--}if(o<1||s>e.getLineCount())return null;const c=e.getLineMaxColumn(o),h=(0,S.h)(this._autoIndent,e,new l.Q(o,c,o,c),this._languageConfigurationService);return this.parseEnterResult(e,t,i,s,h)}trimStart(e){return e.replace(/^\s+/,"")}shouldAutoIndent(e,t){if(this._autoIndent<4)return!1;if(!e.tokenization.isCheapToTokenize(t.startLineNumber))return!1;const i=e.getLanguageIdAtPosition(t.startLineNumber,1);return i===e.getLanguageIdAtPosition(t.endLineNumber,1)&&null!==this._languageConfigurationService.getLanguageConfiguration(i).indentRulesSupport}getIndentEditsOfMovingBlock(e,t,i,s,n,r){for(let o=i.startLineNumber;o<=i.endLineNumber;o++){const c=e.getLineContent(o),h=a.UU(c),d=E.c(h,s)+r,u=E.k(d,s,n);u!==h&&(t.addEditOperation(new l.Q(o,1,o,h.length+1),u),o===i.endLineNumber&&i.endColumn<=h.length+1&&""===u&&(this._moveEndLineSelectionShrink=!0))}}computeCursorState(e,t){let i=t.getTrackedSelection(this._selectionId);return this._moveEndPositionDown&&(i=i.setEndPosition(i.endLineNumber+1,1)),this._moveEndLineSelectionShrink&&i.startLineNumber=n)return null;const r=[];for(let a=s;a<=n;a++)r.push(e.getLineContent(a));let o=r.slice(0);return o.sort(L.getCollator().compare),!0===i&&(o=o.reverse()),{startLineNumber:s,endLineNumber:n,before:r,after:o}}var x=i(78209),k=i(27195),A=i(84001);class N extends r.ks{constructor(e,t){super(t),this.down=e}run(e,t){if(!t.hasModel())return;const i=t.getSelections().map(((e,t)=>({selection:e,index:t,ignore:!1})));i.sort(((e,t)=>l.Q.compareRangesUsingStarts(e.selection,t.selection)));let s=i[0];for(let r=1;rnew g.y(e.positionLineNumber,e.positionColumn))));const n=t.getSelection();if(null===n)return;const r=e.get(A.pG),o=t.getModel(),a=r.getValue("files.trimTrailingWhitespaceInRegexAndStrings",{overrideIdentifier:o?.getLanguageId(),resource:o?.uri}),c=new h(n,s,a);t.pushUndoStop(),t.executeCommands(this.id,[c]),t.pushUndoStop()}}class F extends r.ks{constructor(){super({id:"editor.action.deleteLines",label:x.kg("lines.delete","Delete Line"),alias:"Delete Line",precondition:m.R.writable,kbOpts:{kbExpr:m.R.textInputFocus,primary:3113,weight:100}})}run(e,t){if(!t.hasModel())return;const i=this._getLinesToRemove(t),s=t.getModel();if(1===s.getLineCount()&&1===s.getLineMaxColumn(1))return;let n=0;const r=[],o=[];for(let a=0,l=i.length;a1&&(t-=1,h=s.getLineMaxColumn(t)),r.push(c.k.replace(new p.L(t,h,l,d),"")),o.push(new p.L(t-n,e.positionColumn,t-n,e.positionColumn)),n+=e.endLineNumber-e.startLineNumber+1}t.pushUndoStop(),t.executeEdits(this.id,r,o),t.pushUndoStop()}_getLinesToRemove(e){const t=e.getSelections().map((e=>{let t=e.endLineNumber;return e.startLineNumbere.startLineNumber===t.startLineNumber?e.endLineNumber-t.endLineNumber:e.startLineNumber-t.startLineNumber));const i=[];let s=t[0];for(let n=1;n=t[n].startLineNumber?s.endLineNumber=t[n].endLineNumber:(i.push(s),s=t[n]);return i.push(s),i}}class U extends r.ks{constructor(){super({id:"editor.action.indentLines",label:x.kg("lines.indent","Indent Line"),alias:"Indent Line",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:2142,weight:100}})}run(e,t){const i=t._getViewModel();i&&(t.pushUndoStop(),t.executeCommands(this.id,d.T.indent(i.cursorConfig,t.getModel(),t.getSelections())),t.pushUndoStop())}}class H extends r.ks{constructor(){super({id:"editor.action.outdentLines",label:x.kg("lines.outdent","Outdent Line"),alias:"Outdent Line",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:2140,weight:100}})}run(e,t){n.Yh.Outdent.runEditorCommand(e,t,null)}}class B extends r.ks{constructor(){super({id:"editor.action.insertLineBefore",label:x.kg("lines.insertBefore","Insert Line Above"),alias:"Insert Line Above",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:3075,weight:100}})}run(e,t){const i=t._getViewModel();i&&(t.pushUndoStop(),t.executeCommands(this.id,u.AO.lineInsertBefore(i.cursorConfig,t.getModel(),t.getSelections())))}}class W extends r.ks{constructor(){super({id:"editor.action.insertLineAfter",label:x.kg("lines.insertAfter","Insert Line Below"),alias:"Insert Line Below",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:2051,weight:100}})}run(e,t){const i=t._getViewModel();i&&(t.pushUndoStop(),t.executeCommands(this.id,u.AO.lineInsertAfter(i.cursorConfig,t.getModel(),t.getSelections())))}}class V extends r.ks{run(e,t){if(!t.hasModel())return;const i=t.getSelection(),s=this._getRangesToDelete(t),n=[];for(let a=0,c=s.length-1;ac.k.replace(e,"")));t.pushUndoStop(),t.executeEdits(this.id,o,r),t.pushUndoStop()}}class z extends r.ks{constructor(){super({id:"editor.action.joinLines",label:x.kg("lines.joinLines","Join Lines"),alias:"Join Lines",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:0,mac:{primary:296},weight:100}})}run(e,t){const i=t.getSelections();if(null===i)return;let s=t.getSelection();if(null===s)return;i.sort(l.Q.compareRangesUsingStarts);const n=[],r=i.reduce(((e,t)=>e.isEmpty()?e.endLineNumber===t.startLineNumber?(s.equalsSelection(e)&&(s=t),t):t.startLineNumber>e.endLineNumber+1?(n.push(e),t):new p.L(e.startLineNumber,e.startColumn,t.endLineNumber,t.endColumn):t.startLineNumber>e.endLineNumber?(n.push(e),t):new p.L(e.startLineNumber,e.startColumn,t.endLineNumber,t.endColumn)));n.push(r);const o=t.getModel();if(null===o)return;const a=[],h=[];let d=s,u=0;for(let g=0,m=n.length;g=1){let i=!0;""===v&&(i=!1),!i||" "!==v.charAt(v.length-1)&&"\t"!==v.charAt(v.length-1)||(i=!1,v=v.replace(/[\s\uFEFF\xA0]+$/g," "));const s=e.substr(t-1);v+=(i?" ":"")+s,f=i?s.length+1:s.length}else f=0}const C=new l.Q(t,i,r,m);if(!C.isEmpty()){let i;e.isEmpty()?(a.push(c.k.replace(C,v)),i=new p.L(C.startLineNumber-u,v.length-f+1,t-u,v.length-f+1)):e.startLineNumber===e.endLineNumber?(a.push(c.k.replace(C,v)),i=new p.L(e.startLineNumber-u,e.startColumn,e.endLineNumber-u,e.endColumn)):(a.push(c.k.replace(C,v)),i=new p.L(e.startLineNumber-u,e.startColumn,e.startLineNumber-u,v.length-_)),null!==l.Q.intersectRanges(C,s)?d=i:h.push(i)}u+=C.endLineNumber-C.startLineNumber}h.unshift(d),t.pushUndoStop(),t.executeEdits(this.id,a,h),t.pushUndoStop()}}class G extends r.ks{constructor(){super({id:"editor.action.transpose",label:x.kg("editor.transpose","Transpose Characters around the Cursor"),alias:"Transpose Characters around the Cursor",precondition:m.R.writable})}run(e,t){const i=t.getSelections();if(null===i)return;const s=t.getModel();if(null===s)return;const n=[];for(let r=0,a=i.length;r=a){if(t.lineNumber===s.getLineCount())continue;const e=new l.Q(t.lineNumber,Math.max(1,t.column-1),t.lineNumber+1,1),i=s.getValueInRange(e).split("").reverse().join("");n.push(new o.iu(new p.L(t.lineNumber,Math.max(1,t.column-1),t.lineNumber+1,1),i))}else{const e=new l.Q(t.lineNumber,Math.max(1,t.column-1),t.lineNumber,t.column+1),i=s.getValueInRange(e).split("").reverse().join("");n.push(new o.ui(e,i,new p.L(t.lineNumber,t.column+1,t.lineNumber,t.column+1)))}}t.pushUndoStop(),t.executeCommands(this.id,n),t.pushUndoStop()}}class j extends r.ks{run(e,t){const i=t.getSelections();if(null===i)return;const s=t.getModel();if(null===s)return;const n=t.getOption(132),r=[];for(const o of i)if(o.isEmpty()){const e=o.getStartPosition(),i=t.getConfiguredWordAtPosition(e);if(!i)continue;const a=new l.Q(e.lineNumber,i.startColumn,e.lineNumber,i.endColumn),h=s.getValueInRange(a);r.push(c.k.replace(a,this._modifyText(h,n)))}else{const e=s.getValueInRange(o);r.push(c.k.replace(o,this._modifyText(e,n)))}t.pushUndoStop(),t.executeEdits(this.id,r),t.pushUndoStop()}}class K{constructor(e,t){this._pattern=e,this._flags=t,this._actual=null,this._evaluated=!1}get(){if(!this._evaluated){this._evaluated=!0;try{this._actual=new RegExp(this._pattern,this._flags)}catch(e){}}return this._actual}isSupported(){return null!==this.get()}}class Y extends j{static{this.titleBoundary=new K("(^|[^\\p{L}\\p{N}']|((^|\\P{L})'))\\p{L}","gmu")}constructor(){super({id:"editor.action.transformToTitlecase",label:x.kg("editor.transformToTitlecase","Transform to Title Case"),alias:"Transform to Title Case",precondition:m.R.writable})}_modifyText(e,t){const i=Y.titleBoundary.get();return i?e.toLocaleLowerCase().replace(i,(e=>e.toLocaleUpperCase())):e}}class q extends j{static{this.caseBoundary=new K("(\\p{Ll})(\\p{Lu})","gmu")}static{this.singleLetters=new K("(\\p{Lu}|\\p{N})(\\p{Lu})(\\p{Ll})","gmu")}constructor(){super({id:"editor.action.transformToSnakecase",label:x.kg("editor.transformToSnakecase","Transform to Snake Case"),alias:"Transform to Snake Case",precondition:m.R.writable})}_modifyText(e,t){const i=q.caseBoundary.get(),s=q.singleLetters.get();return i&&s?e.replace(i,"$1_$2").replace(s,"$1_$2$3").toLocaleLowerCase():e}}class $ extends j{static{this.wordBoundary=new K("[_\\s-]","gm")}constructor(){super({id:"editor.action.transformToCamelcase",label:x.kg("editor.transformToCamelcase","Transform to Camel Case"),alias:"Transform to Camel Case",precondition:m.R.writable})}_modifyText(e,t){const i=$.wordBoundary.get();if(!i)return e;const s=e.split(i);return s.shift()+s.map((e=>e.substring(0,1).toLocaleUpperCase()+e.substring(1))).join("")}}class Q extends j{static{this.wordBoundary=new K("[_\\s-]","gm")}static{this.wordBoundaryToMaintain=new K("(?<=\\.)","gm")}constructor(){super({id:"editor.action.transformToPascalcase",label:x.kg("editor.transformToPascalcase","Transform to Pascal Case"),alias:"Transform to Pascal Case",precondition:m.R.writable})}_modifyText(e,t){const i=Q.wordBoundary.get(),s=Q.wordBoundaryToMaintain.get();if(!i||!s)return e;return e.split(s).map((e=>e.split(i))).flat().map((e=>e.substring(0,1).toLocaleUpperCase()+e.substring(1))).join("")}}class X extends j{static isSupported(){return[this.caseBoundary,this.singleLetters,this.underscoreBoundary].every((e=>e.isSupported()))}static{this.caseBoundary=new K("(\\p{Ll})(\\p{Lu})","gmu")}static{this.singleLetters=new K("(\\p{Lu}|\\p{N})(\\p{Lu}\\p{Ll})","gmu")}static{this.underscoreBoundary=new K("(\\S)(_)(\\S)","gm")}constructor(){super({id:"editor.action.transformToKebabcase",label:x.kg("editor.transformToKebabcase","Transform to Kebab Case"),alias:"Transform to Kebab Case",precondition:m.R.writable})}_modifyText(e,t){const i=X.caseBoundary.get(),s=X.singleLetters.get(),n=X.underscoreBoundary.get();return i&&s&&n?e.replace(n,"$1-$3").replace(i,"$1-$2").replace(s,"$1-$2").toLocaleLowerCase():e}}(0,r.Fl)(class extends N{constructor(){super(!1,{id:"editor.action.copyLinesUpAction",label:x.kg("lines.copyUp","Copy Line Up"),alias:"Copy Line Up",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:1552,linux:{primary:3600},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miCopyLinesUp",comment:["&& denotes a mnemonic"]},"&&Copy Line Up"),order:1}})}}),(0,r.Fl)(class extends N{constructor(){super(!0,{id:"editor.action.copyLinesDownAction",label:x.kg("lines.copyDown","Copy Line Down"),alias:"Copy Line Down",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:1554,linux:{primary:3602},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miCopyLinesDown",comment:["&& denotes a mnemonic"]},"Co&&py Line Down"),order:2}})}}),(0,r.Fl)(I),(0,r.Fl)(class extends O{constructor(){super(!1,{id:"editor.action.moveLinesUpAction",label:x.kg("lines.moveUp","Move Line Up"),alias:"Move Line Up",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:528,linux:{primary:528},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miMoveLinesUp",comment:["&& denotes a mnemonic"]},"Mo&&ve Line Up"),order:3}})}}),(0,r.Fl)(class extends O{constructor(){super(!0,{id:"editor.action.moveLinesDownAction",label:x.kg("lines.moveDown","Move Line Down"),alias:"Move Line Down",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:530,linux:{primary:530},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miMoveLinesDown",comment:["&& denotes a mnemonic"]},"Move &&Line Down"),order:4}})}}),(0,r.Fl)(class extends D{constructor(){super(!1,{id:"editor.action.sortLinesAscending",label:x.kg("lines.sortAscending","Sort Lines Ascending"),alias:"Sort Lines Ascending",precondition:m.R.writable})}}),(0,r.Fl)(class extends D{constructor(){super(!0,{id:"editor.action.sortLinesDescending",label:x.kg("lines.sortDescending","Sort Lines Descending"),alias:"Sort Lines Descending",precondition:m.R.writable})}}),(0,r.Fl)(M),(0,r.Fl)(P),(0,r.Fl)(F),(0,r.Fl)(U),(0,r.Fl)(H),(0,r.Fl)(B),(0,r.Fl)(W),(0,r.Fl)(class extends V{constructor(){super({id:"deleteAllLeft",label:x.kg("lines.deleteAllLeft","Delete All Left"),alias:"Delete All Left",precondition:m.R.writable,kbOpts:{kbExpr:m.R.textInputFocus,primary:0,mac:{primary:2049},weight:100}})}_getEndCursorState(e,t){let i=null;const s=[];let n=0;return t.forEach((t=>{let r;if(1===t.endColumn&&n>0){const e=t.startLineNumber-n;r=new p.L(e,t.startColumn,e,t.startColumn)}else r=new p.L(t.startLineNumber,t.startColumn,t.startLineNumber,t.startColumn);n+=t.endLineNumber-t.startLineNumber,t.intersectRanges(e)?i=r:s.push(r)})),i&&s.unshift(i),s}_getRangesToDelete(e){const t=e.getSelections();if(null===t)return[];let i=t;const s=e.getModel();return null===s?[]:(i.sort(l.Q.compareRangesUsingStarts),i=i.map((e=>{if(e.isEmpty()){if(1===e.startColumn){const t=Math.max(1,e.startLineNumber-1),i=1===e.startLineNumber?1:s.getLineLength(t)+1;return new l.Q(t,i,e.startLineNumber,1)}return new l.Q(e.startLineNumber,1,e.startLineNumber,e.startColumn)}return new l.Q(e.startLineNumber,1,e.endLineNumber,e.endColumn)})),i)}}),(0,r.Fl)(class extends V{constructor(){super({id:"deleteAllRight",label:x.kg("lines.deleteAllRight","Delete All Right"),alias:"Delete All Right",precondition:m.R.writable,kbOpts:{kbExpr:m.R.textInputFocus,primary:0,mac:{primary:297,secondary:[2068]},weight:100}})}_getEndCursorState(e,t){let i=null;const s=[];for(let n=0,r=t.length,o=0;n{if(e.isEmpty()){const i=t.getLineMaxColumn(e.startLineNumber);return e.startColumn===i?new l.Q(e.startLineNumber,e.startColumn,e.startLineNumber+1,1):new l.Q(e.startLineNumber,e.startColumn,e.startLineNumber,i)}return e}));return s.sort(l.Q.compareRangesUsingStarts),s}}),(0,r.Fl)(z),(0,r.Fl)(G),(0,r.Fl)(class extends j{constructor(){super({id:"editor.action.transformToUppercase",label:x.kg("editor.transformToUppercase","Transform to Uppercase"),alias:"Transform to Uppercase",precondition:m.R.writable})}_modifyText(e,t){return e.toLocaleUpperCase()}}),(0,r.Fl)(class extends j{constructor(){super({id:"editor.action.transformToLowercase",label:x.kg("editor.transformToLowercase","Transform to Lowercase"),alias:"Transform to Lowercase",precondition:m.R.writable})}_modifyText(e,t){return e.toLocaleLowerCase()}}),q.caseBoundary.isSupported()&&q.singleLetters.isSupported()&&(0,r.Fl)(q),$.wordBoundary.isSupported()&&(0,r.Fl)($),Q.wordBoundary.isSupported()&&(0,r.Fl)(Q),Y.titleBoundary.isSupported()&&(0,r.Fl)(Y),X.isSupported()&&(0,r.Fl)(X)},76007:(e,t,i)=>{"use strict";i.r(t),i.d(t,{LanguageFeaturesService:()=>g});var s=i(41234),n=i(5662),r=i(16223),o=i(54459);function a(e){return"string"!==typeof e&&(Array.isArray(e)?e.every(a):!!e.exclusive)}class c{constructor(e,t,i,s,n){this.uri=e,this.languageId=t,this.notebookUri=i,this.notebookType=s,this.recursive=n}equals(e){return this.notebookType===e.notebookType&&this.languageId===e.languageId&&this.uri.toString()===e.uri.toString()&&this.notebookUri?.toString()===e.notebookUri?.toString()&&this.recursive===e.recursive}}class l{constructor(e){this._notebookInfoResolver=e,this._clock=0,this._entries=[],this._onDidChange=new s.vl,this.onDidChange=this._onDidChange.event}register(e,t){let i={selector:e,provider:t,_score:-1,_time:this._clock++};return this._entries.push(i),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),(0,n.s)((()=>{if(i){const e=this._entries.indexOf(i);e>=0&&(this._entries.splice(e,1),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),i=void 0)}}))}has(e){return this.all(e).length>0}all(e){if(!e)return[];this._updateScores(e,!1);const t=[];for(const i of this._entries)i._score>0&&t.push(i.provider);return t}ordered(e,t=!1){const i=[];return this._orderedForEach(e,t,(e=>i.push(e.provider))),i}orderedGroups(e){const t=[];let i,s;return this._orderedForEach(e,!1,(e=>{i&&s===e._score?i.push(e.provider):(s=e._score,i=[e.provider],t.push(i))})),t}_orderedForEach(e,t,i){this._updateScores(e,t);for(const s of this._entries)s._score>0&&i(s)}_updateScores(e,t){const i=this._notebookInfoResolver?.(e.uri),s=i?new c(e.uri,e.getLanguageId(),i.uri,i.type,t):new c(e.uri,e.getLanguageId(),void 0,void 0,t);if(!this._lastCandidate?.equals(s)){this._lastCandidate=s;for(const i of this._entries)if(i._score=(0,o.f)(i.selector,s.uri,s.languageId,(0,r.vd)(e),s.notebookUri,s.notebookType),a(i.selector)&&i._score>0){if(!t){for(const e of this._entries)e._score=0;i._score=1e3;break}i._score=0}this._entries.sort(l._compareByScoreAndTime)}}static _compareByScoreAndTime(e,t){return e._scoret._score?-1:h(e.selector)&&!h(t.selector)?1:!h(e.selector)&&h(t.selector)?-1:e._timet._time?-1:0}}function h(e){return"string"!==typeof e&&(Array.isArray(e)?e.some(h):Boolean(e.isBuiltin))}var d=i(56942),u=i(14718);class g{constructor(){this.referenceProvider=new l(this._score.bind(this)),this.renameProvider=new l(this._score.bind(this)),this.newSymbolNamesProvider=new l(this._score.bind(this)),this.codeActionProvider=new l(this._score.bind(this)),this.definitionProvider=new l(this._score.bind(this)),this.typeDefinitionProvider=new l(this._score.bind(this)),this.declarationProvider=new l(this._score.bind(this)),this.implementationProvider=new l(this._score.bind(this)),this.documentSymbolProvider=new l(this._score.bind(this)),this.inlayHintsProvider=new l(this._score.bind(this)),this.colorProvider=new l(this._score.bind(this)),this.codeLensProvider=new l(this._score.bind(this)),this.documentFormattingEditProvider=new l(this._score.bind(this)),this.documentRangeFormattingEditProvider=new l(this._score.bind(this)),this.onTypeFormattingEditProvider=new l(this._score.bind(this)),this.signatureHelpProvider=new l(this._score.bind(this)),this.hoverProvider=new l(this._score.bind(this)),this.documentHighlightProvider=new l(this._score.bind(this)),this.multiDocumentHighlightProvider=new l(this._score.bind(this)),this.selectionRangeProvider=new l(this._score.bind(this)),this.foldingRangeProvider=new l(this._score.bind(this)),this.linkProvider=new l(this._score.bind(this)),this.inlineCompletionsProvider=new l(this._score.bind(this)),this.inlineEditProvider=new l(this._score.bind(this)),this.completionProvider=new l(this._score.bind(this)),this.linkedEditingRangeProvider=new l(this._score.bind(this)),this.documentRangeSemanticTokensProvider=new l(this._score.bind(this)),this.documentSemanticTokensProvider=new l(this._score.bind(this)),this.documentDropEditProvider=new l(this._score.bind(this)),this.documentPasteEditProvider=new l(this._score.bind(this))}_score(e){return this._notebookTypeResolver?.(e)}}(0,u.v)(d.ILanguageFeaturesService,g,1)},76319:(e,t,i)=>{e.exports=function(e){const t=i(94297);return function(i,s,n){const r=s.limitListLength>0&&i.length>s.limitListLength;return(r?i.slice(0,s.limitListLength-1):i).map((function(t){return e(t,s,n+1)})).concat(r?["... "+(i.length-s.limitListLength+1)+" hidden items"]:[]).join(t.getExpressionTerminator(s)+t.getIndent(s,n))}}},76440:(e,t,i)=>{"use strict";var s=i(31450),n=i(57039),r=i(21478),o=i(68250);(0,s.HW)(r.M.ID,r.M,1),n.B2.register(o.u)},76495:(e,t,i)=>{"use strict";i.d(t,{hW:()=>r});var s=i(78049),n=i(44026);class r{constructor(e,t,i){this.editorModel=e,this.languageConfigurationService=t,this.foldingRangesLimit=i,this.id="indent"}dispose(){}compute(e){const t=this.languageConfigurationService.getLanguageConfiguration(this.editorModel.getLanguageId()).foldingRules,i=t&&!!t.offSide,n=t&&t.markers;return Promise.resolve(function(e,t,i,n=a){const r=e.getOptions().tabSize,c=new o(n);let l;i&&(l=new RegExp(`(${i.start.source})|(?:${i.end.source})`));const h=[],d=e.getLineCount()+1;h.push({indent:-1,endAbove:d,line:d});for(let o=e.getLineCount();o>0;o--){const i=e.getLineContent(o),n=(0,s.G)(i,r);let a,d=h[h.length-1];if(-1!==n){if(l&&(a=i.match(l))){if(!a[1]){h.push({indent:-2,endAbove:o,line:o});continue}{let e=h.length-1;for(;e>0&&-2!==h[e].indent;)e--;if(e>0){h.length=e+1,d=h[e],c.insertFirst(o,d.line,n),d.line=o,d.indent=n,d.endAbove=o;continue}}}if(d.indent>n){do{h.pop(),d=h[h.length-1]}while(d.indent>n);const e=d.endAbove-1;e-o>=1&&c.insertFirst(o,e,n)}d.indent===n?d.endAbove=o:h.push({indent:n,endAbove:o,line:o})}else t&&(d.endAbove=o)}return c.toIndentRanges(e)}(this.editorModel,i,n,this.foldingRangesLimit))}}class o{constructor(e){this._startIndexes=[],this._endIndexes=[],this._indentOccurrences=[],this._length=0,this._foldingRangesLimit=e}insertFirst(e,t,i){if(e>n.yy||t>n.yy)return;const s=this._length;this._startIndexes[s]=e,this._endIndexes[s]=t,this._length++,i<1e3&&(this._indentOccurrences[i]=(this._indentOccurrences[i]||0)+1)}toIndentRanges(e){const t=this._foldingRangesLimit.limit;if(this._length<=t){this._foldingRangesLimit.update(this._length,!1);const e=new Uint32Array(this._length),t=new Uint32Array(this._length);for(let i=this._length-1,s=0;i>=0;i--,s++)e[s]=this._startIndexes[i],t[s]=this._endIndexes[i];return new n.tz(e,t)}{this._foldingRangesLimit.update(this._length,t);let i=0,r=this._indentOccurrences.length;for(let e=0;et){r=e;break}i+=s}}const o=e.getOptions().tabSize,a=new Uint32Array(t),c=new Uint32Array(t);for(let n=this._length-1,l=0;n>=0;n--){const h=this._startIndexes[n],d=e.getLineContent(h),u=(0,s.G)(d,o);(u{}}},76531:(e,t,i)=>{!function(){"use strict";const t=i(85858),s="$type",n="$value",r="$attributes";function o(e,t){return e&&Object.prototype.hasOwnProperty.call(e,t)&&"undefined"!==typeof e[t]}function a(e){return o(e,n)?e[n]:e}e.exports={hasSpecialProperty:o,attributes:function(e){return o(e,r)?e[r]:{}},value:a,type:function(e){return o(e,s)?e[s]:t(a(e))},ATTRIBUTES_KEY:r,VALUE_KEY:n,TYPE_KEY:s,INCOMPLETE_KEY:"$incomplete",BINARY_KEY:"$binary"}}()},77011:(e,t,i)=>{"use strict";i.d(t,{A:()=>q});var s=i(87758),n=i(5662),r=i(63591),o=i(64317),a=i(98031),c=i(90766),l=i(51219),h=i(8597),d=i(62083),u=i(12143),g=i(57039),p=i(88807),m=i(83069);class f extends n.jG{constructor(e,t=new h.fg(10,10)){super(),this._editor=e,this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this._resizableNode=this._register(new p.v),this._contentPosition=null,this._isResizing=!1,this._resizableNode.domNode.style.position="absolute",this._resizableNode.minSize=h.fg.lift(t),this._resizableNode.layout(t.height,t.width),this._resizableNode.enableSashes(!0,!0,!0,!0),this._register(this._resizableNode.onDidResize((e=>{this._resize(new h.fg(e.dimension.width,e.dimension.height)),e.done&&(this._isResizing=!1)}))),this._register(this._resizableNode.onDidWillResize((()=>{this._isResizing=!0})))}get isResizing(){return this._isResizing}getDomNode(){return this._resizableNode.domNode}getPosition(){return this._contentPosition}get position(){return this._contentPosition?.position?m.y.lift(this._contentPosition.position):void 0}_availableVerticalSpaceAbove(e){const t=this._editor.getDomNode(),i=this._editor.getScrolledVisiblePosition(e);if(!t||!i)return;return h.BK(t).top+i.top-30}_availableVerticalSpaceBelow(e){const t=this._editor.getDomNode(),i=this._editor.getScrolledVisiblePosition(e);if(!t||!i)return;const s=h.BK(t),n=h.tG(t.ownerDocument.body),r=s.top+i.top+i.height;return n.height-r-24}_findPositionPreference(e,t){const i=Math.min(this._availableVerticalSpaceBelow(t)??1/0,e),s=Math.min(this._availableVerticalSpaceAbove(t)??1/0,e),n=Math.min(Math.max(s,i),e),r=Math.min(e,n);let o;return o=this._editor.getOption(60).above?r<=s?1:2:r<=i?2:1,1===o?this._resizableNode.enableSashes(!0,!0,!1,!1):this._resizableNode.enableSashes(!1,!0,!0,!1),o}_resize(e){this._resizableNode.layout(e.height,e.width)}}var _,v=i(32848),C=i(84001),E=i(253),b=i(60002),S=i(52776),y=i(41234),w=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},R=function(e,t){return function(i,s){t(i,s,e)}};let L=class extends f{static{_=this}static{this.ID="editor.contrib.resizableContentHoverWidget"}static{this._lastDimensions=new h.fg(0,0)}get isVisibleFromKeyboard(){return 1===this._renderedHover?.source}get isVisible(){return this._hoverVisibleKey.get()??!1}get isFocused(){return this._hoverFocusedKey.get()??!1}constructor(e,t,i,s,n){const r=e.getOption(67)+8,o=new h.fg(150,r);super(e,o),this._configurationService=i,this._accessibilityService=s,this._keybindingService=n,this._hover=this._register(new S.N4),this._onDidResize=this._register(new y.vl),this.onDidResize=this._onDidResize.event,this._minimumSize=o,this._hoverVisibleKey=b.R.hoverVisible.bindTo(t),this._hoverFocusedKey=b.R.hoverFocused.bindTo(t),h.BC(this._resizableNode.domNode,this._hover.containerDomNode),this._resizableNode.domNode.style.zIndex="50",this._register(this._editor.onDidLayoutChange((()=>{this.isVisible&&this._updateMaxDimensions()}))),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(50)&&this._updateFont()})));const a=this._register(h.w5(this._resizableNode.domNode));this._register(a.onDidFocus((()=>{this._hoverFocusedKey.set(!0)}))),this._register(a.onDidBlur((()=>{this._hoverFocusedKey.set(!1)}))),this._setRenderedHover(void 0),this._editor.addContentWidget(this)}dispose(){super.dispose(),this._renderedHover?.dispose(),this._editor.removeContentWidget(this)}getId(){return _.ID}static _applyDimensions(e,t,i){const s="number"===typeof t?`${t}px`:t,n="number"===typeof i?`${i}px`:i;e.style.width=s,e.style.height=n}_setContentsDomNodeDimensions(e,t){const i=this._hover.contentsDomNode;return _._applyDimensions(i,e,t)}_setContainerDomNodeDimensions(e,t){const i=this._hover.containerDomNode;return _._applyDimensions(i,e,t)}_setHoverWidgetDimensions(e,t){this._setContentsDomNodeDimensions(e,t),this._setContainerDomNodeDimensions(e,t),this._layoutContentWidget()}static _applyMaxDimensions(e,t,i){const s="number"===typeof t?`${t}px`:t,n="number"===typeof i?`${i}px`:i;e.style.maxWidth=s,e.style.maxHeight=n}_setHoverWidgetMaxDimensions(e,t){_._applyMaxDimensions(this._hover.contentsDomNode,e,t),_._applyMaxDimensions(this._hover.containerDomNode,e,t),this._hover.containerDomNode.style.setProperty("--vscode-hover-maxWidth","number"===typeof e?`${e}px`:e),this._layoutContentWidget()}_setAdjustedHoverWidgetDimensions(e){this._setHoverWidgetMaxDimensions("none","none");const t=e.width,i=e.height;this._setHoverWidgetDimensions(t,i)}_updateResizableNodeMaxDimensions(){const e=this._findMaximumRenderingWidth()??1/0,t=this._findMaximumRenderingHeight()??1/0;this._resizableNode.maxSize=new h.fg(e,t),this._setHoverWidgetMaxDimensions(e,t)}_resize(e){_._lastDimensions=new h.fg(e.width,e.height),this._setAdjustedHoverWidgetDimensions(e),this._resizableNode.layout(e.height,e.width),this._updateResizableNodeMaxDimensions(),this._hover.scrollbar.scanDomNode(),this._editor.layoutContentWidget(this),this._onDidResize.fire()}_findAvailableSpaceVertically(){const e=this._renderedHover?.showAtPosition;if(e)return 1===this._positionPreference?this._availableVerticalSpaceAbove(e):this._availableVerticalSpaceBelow(e)}_findMaximumRenderingHeight(){const e=this._findAvailableSpaceVertically();if(!e)return;let t=6;return Array.from(this._hover.contentsDomNode.children).forEach((e=>{t+=e.clientHeight})),Math.min(e,t)}_isHoverTextOverflowing(){this._hover.containerDomNode.style.setProperty("--vscode-hover-whiteSpace","nowrap"),this._hover.containerDomNode.style.setProperty("--vscode-hover-sourceWhiteSpace","nowrap");const e=Array.from(this._hover.contentsDomNode.children).some((e=>e.scrollWidth>e.clientWidth));return this._hover.containerDomNode.style.removeProperty("--vscode-hover-whiteSpace"),this._hover.containerDomNode.style.removeProperty("--vscode-hover-sourceWhiteSpace"),e}_findMaximumRenderingWidth(){if(!this._editor||!this._editor.hasModel())return;const e=this._isHoverTextOverflowing(),t="undefined"===typeof this._contentWidth?0:this._contentWidth-2;if(e||this._hover.containerDomNode.clientWidththis._renderedHover.closestMouseDistance+4)&&(this._renderedHover.closestMouseDistance=Math.min(this._renderedHover.closestMouseDistance,s),!0)}_setRenderedHover(e){this._renderedHover?.dispose(),this._renderedHover=e,this._hoverVisibleKey.set(!!e),this._hover.containerDomNode.classList.toggle("hidden",!e)}_updateFont(){const{fontSize:e,lineHeight:t}=this._editor.getOption(50),i=this._hover.contentsDomNode;i.style.fontSize=`${e}px`,i.style.lineHeight=""+t/e;Array.prototype.slice.call(this._hover.contentsDomNode.getElementsByClassName("code")).forEach((e=>this._editor.applyFontInfo(e)))}_updateContent(e){const t=this._hover.contentsDomNode;t.style.paddingBottom="",t.textContent="",t.appendChild(e)}_layoutContentWidget(){this._editor.layoutContentWidget(this),this._hover.onContentsChanged()}_updateMaxDimensions(){const e=Math.max(this._editor.getLayoutInfo().height/4,250,_._lastDimensions.height),t=Math.max(.66*this._editor.getLayoutInfo().width,500,_._lastDimensions.width);this._setHoverWidgetMaxDimensions(t,e)}_render(e){this._setRenderedHover(e),this._updateFont(),this._updateContent(e.domNode),this._updateMaxDimensions(),this.onContentsChanged(),this._editor.render()}getPosition(){return this._renderedHover?{position:this._renderedHover.showAtPosition,secondaryPosition:this._renderedHover.showAtSecondaryPosition,positionAffinity:this._renderedHover.shouldAppearBeforeContent?3:void 0,preference:[this._positionPreference??1]}:null}show(e){if(!this._editor||!this._editor.hasModel())return;this._render(e);const t=h.OK(this._hover.containerDomNode),i=e.showAtPosition;this._positionPreference=this._findPositionPreference(t,i)??1,this.onContentsChanged(),e.shouldFocus&&this._hover.containerDomNode.focus(),this._onDidResize.fire();const s=this._hover.containerDomNode.ownerDocument.activeElement===this._hover.containerDomNode&&(0,S.vr)(!0===this._configurationService.getValue("accessibility.verbosity.hover")&&this._accessibilityService.isScreenReaderOptimized(),this._keybindingService.lookupKeybinding("editor.action.accessibleView")?.getAriaLabel()??"");s&&(this._hover.contentsDomNode.ariaLabel=this._hover.contentsDomNode.textContent+", "+s)}hide(){if(!this._renderedHover)return;const e=this._renderedHover.shouldFocus||this._hoverFocusedKey.get();this._setRenderedHover(void 0),this._resizableNode.maxSize=new h.fg(1/0,1/0),this._resizableNode.clearSashHoverState(),this._hoverFocusedKey.set(!1),this._editor.layoutContentWidget(this),e&&this._editor.focus()}_removeConstraintsRenderNormally(){const e=this._editor.getLayoutInfo();this._resizableNode.layout(e.height,e.width),this._setHoverWidgetDimensions("auto","auto")}setMinimumDimensions(e){this._minimumSize=new h.fg(Math.max(this._minimumSize.width,e.width),Math.max(this._minimumSize.height,e.height)),this._updateMinimumWidth()}_updateMinimumWidth(){const e="undefined"===typeof this._contentWidth?this._minimumSize.width:Math.min(this._contentWidth,this._minimumSize.width);this._resizableNode.minSize=new h.fg(e,this._minimumSize.height)}onContentsChanged(){this._removeConstraintsRenderNormally();const e=this._hover.containerDomNode;let t=h.OK(e),i=h.Tr(e);if(this._resizableNode.layout(t,i),this._setHoverWidgetDimensions(i,t),t=h.OK(e),i=h.Tr(e),this._contentWidth=i,this._updateMinimumWidth(),this._resizableNode.layout(t,i),this._renderedHover?.showAtPosition){const e=h.OK(this._hover.containerDomNode);this._positionPreference=this._findPositionPreference(e,this._renderedHover.showAtPosition)}this._layoutContentWidget()}focus(){this._hover.containerDomNode.focus()}scrollUp(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._editor.getOption(50);this._hover.scrollbar.setScrollPosition({scrollTop:e-t.lineHeight})}scrollDown(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._editor.getOption(50);this._hover.scrollbar.setScrollPosition({scrollTop:e+t.lineHeight})}scrollLeft(){const e=this._hover.scrollbar.getScrollPosition().scrollLeft;this._hover.scrollbar.setScrollPosition({scrollLeft:e-30})}scrollRight(){const e=this._hover.scrollbar.getScrollPosition().scrollLeft;this._hover.scrollbar.setScrollPosition({scrollLeft:e+30})}pageUp(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._hover.scrollbar.getScrollDimensions().height;this._hover.scrollbar.setScrollPosition({scrollTop:e-t})}pageDown(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._hover.scrollbar.getScrollDimensions().height;this._hover.scrollbar.setScrollPosition({scrollTop:e+t})}goToTop(){this._hover.scrollbar.setScrollPosition({scrollTop:0})}goToBottom(){this._hover.scrollbar.setScrollPosition({scrollTop:this._hover.scrollbar.getScrollDimensions().scrollHeight})}};function T(e,t,i,s,n,r){const o=i+n/2,a=s+r/2,c=Math.max(Math.abs(e-o)-n/2,0),l=Math.max(Math.abs(t-a)-r/2,0);return Math.sqrt(c*c+l*l)}L=_=w([R(1,v.fN),R(2,C.pG),R(3,E.j),R(4,a.b)],L);var x=i(25890);class k{get anchor(){return this._anchor}set anchor(e){this._anchor=e}get shouldFocus(){return this._shouldFocus}set shouldFocus(e){this._shouldFocus=e}get source(){return this._source}set source(e){this._source=e}get insistOnKeepingHoverVisible(){return this._insistOnKeepingHoverVisible}set insistOnKeepingHoverVisible(e){this._insistOnKeepingHoverVisible=e}constructor(e,t){this._editor=e,this._participants=t,this._anchor=null,this._shouldFocus=!1,this._source=0,this._insistOnKeepingHoverVisible=!1}static _getLineDecorations(e,t){if(1!==t.type&&!t.supportsMarkerHover)return[];const i=e.getModel(),s=t.range.startLineNumber;if(s>i.getLineCount())return[];const n=i.getLineMaxColumn(s);return e.getLineDecorations(s).filter((e=>{if(e.options.isWholeLine)return!0;const i=e.range.startLineNumber===s?e.range.startColumn:1,r=e.range.endLineNumber===s?e.range.endColumn:n;if(e.options.showIfCollapsed){if(i>t.range.startColumn+1||t.range.endColumn-1>r)return!1}else if(i>t.range.startColumn||t.range.endColumn>r)return!1;return!0}))}computeAsync(e){const t=this._anchor;if(!this._editor.hasModel()||!t)return c.AE.EMPTY;const i=k._getLineDecorations(this._editor,t);return c.AE.merge(this._participants.map((s=>s.computeAsync?s.computeAsync(t,i,e):c.AE.EMPTY)))}computeSync(){if(!this._editor.hasModel()||!this._anchor)return[];const e=k._getLineDecorations(this._editor,this._anchor);let t=[];for(const i of this._participants)t=t.concat(i.computeSync(this._anchor,e));return(0,x.Yc)(t)}}class A{constructor(e,t,i){this.anchor=e,this.hoverParts=t,this.isComplete=i}filter(e){const t=this.hoverParts.filter((t=>t.isValidForHoverAnchor(e)));return t.length===this.hoverParts.length?this:new N(this,this.anchor,t,this.isComplete)}}class N extends A{constructor(e,t,i,s){super(t,i,s),this.original=e}filter(e){return this.original.filter(e)}}var I=i(9270),O=i(87289),D=i(36677),M=i(57286),P=i(28712),F=i(68250),U=i(64383);class H extends n.jG{constructor(e,t,i,s,n,r){super();const o=t.anchor,a=t.hoverParts;this._renderedHoverParts=this._register(new W(e,i,a,r,n));const{showAtPosition:c,showAtSecondaryPosition:l}=H.computeHoverPositions(e,o.range,a);this.shouldAppearBeforeContent=a.some((e=>e.isBeforeContent)),this.showAtPosition=c,this.showAtSecondaryPosition=l,this.initialMousePosX=o.initialMousePosX,this.initialMousePosY=o.initialMousePosY,this.shouldFocus=s.shouldFocus,this.source=s.source}get domNode(){return this._renderedHoverParts.domNode}get domNodeHasChildren(){return this._renderedHoverParts.domNodeHasChildren}get focusedHoverPartIndex(){return this._renderedHoverParts.focusedHoverPartIndex}async updateHoverVerbosityLevel(e,t,i){this._renderedHoverParts.updateHoverVerbosityLevel(e,t,i)}isColorPickerVisible(){return this._renderedHoverParts.isColorPickerVisible()}static computeHoverPositions(e,t,i){let s=1;if(e.hasModel()){const i=e._getViewModel(),n=i.coordinatesConverter,r=n.convertModelRangeToViewRange(t),o=i.getLineMinColumn(r.startLineNumber),a=new m.y(r.startLineNumber,o);s=n.convertViewPositionToModelPosition(a).column}const n=t.startLineNumber;let r,o,a,c=t.startColumn;for(const l of i){const e=l.range,t=e.startLineNumber===n,i=e.endLineNumber===n;if(t&&i){const t=e.startColumn,i=Math.min(c,t);c=Math.max(i,s)}l.forceShowAtRange&&(r=e)}if(r){const e=r.getStartPosition();o=e,a=e}else o=t.getStartPosition(),a=new m.y(n,c);return{showAtPosition:o,showAtSecondaryPosition:a}}}class B{constructor(e,t){this._statusBar=t,e.appendChild(this._statusBar.hoverElement)}get hoverElement(){return this._statusBar.hoverElement}get actions(){return this._statusBar.actions}dispose(){this._statusBar.dispose()}}class W extends n.jG{static{this._DECORATION_OPTIONS=O.kI.register({description:"content-hover-highlight",className:"hoverHighlight"})}constructor(e,t,i,s,n){super(),this._renderedParts=[],this._focusedHoverPartIndex=-1,this._context=n,this._fragment=document.createDocumentFragment(),this._register(this._renderParts(t,i,n,s)),this._register(this._registerListenersOnRenderedParts()),this._register(this._createEditorDecorations(e,i)),this._updateMarkdownAndColorParticipantInfo(t)}_createEditorDecorations(e,t){if(0===t.length)return n.jG.None;let i=t[0].range;for(const n of t){const e=n.range;i=D.Q.plusRange(i,e)}const s=e.createDecorationsCollection();return s.set([{range:i,options:W._DECORATION_OPTIONS}]),(0,n.s)((()=>{s.clear()}))}_renderParts(e,t,i,s){const r=new I.L(s),o={fragment:this._fragment,statusBar:r,...i},a=new n.Cm;for(const n of e){const e=this._renderHoverPartsForParticipant(t,n,o);a.add(e);for(const t of e.renderedHoverParts)this._renderedParts.push({type:"hoverPart",participant:n,hoverPart:t.hoverPart,hoverElement:t.hoverElement})}const c=this._renderStatusBar(this._fragment,r);return c&&(a.add(c),this._renderedParts.push({type:"statusBar",hoverElement:c.hoverElement,actions:c.actions})),(0,n.s)((()=>{a.dispose()}))}_renderHoverPartsForParticipant(e,t,i){const s=e.filter((e=>e.owner===t));return s.length>0?t.renderHoverParts(i,s):new g.Ke([])}_renderStatusBar(e,t){if(t.hasContent)return new B(e,t)}_registerListenersOnRenderedParts(){const e=new n.Cm;return this._renderedParts.forEach(((t,i)=>{const s=t.hoverElement;s.tabIndex=0,e.add(h.ko(s,h.Bx.FOCUS_IN,(e=>{e.stopPropagation(),this._focusedHoverPartIndex=i}))),e.add(h.ko(s,h.Bx.FOCUS_OUT,(e=>{e.stopPropagation(),this._focusedHoverPartIndex=-1})))})),e}_updateMarkdownAndColorParticipantInfo(e){const t=e.find((e=>e instanceof M.xJ&&!(e instanceof F.u)));t&&(this._markdownHoverParticipant=t),this._colorHoverParticipant=e.find((e=>e instanceof P.BJ))}async updateHoverVerbosityLevel(e,t,i){if(!this._markdownHoverParticipant)return;const s=this._normalizedIndexToMarkdownHoverIndexRange(this._markdownHoverParticipant,t);if(void 0===s)return;const n=await this._markdownHoverParticipant.updateMarkdownHoverVerbosityLevel(e,s,i);n&&(this._renderedParts[t]={type:"hoverPart",participant:this._markdownHoverParticipant,hoverPart:n.hoverPart,hoverElement:n.hoverElement},this._context.onContentsChanged())}isColorPickerVisible(){return this._colorHoverParticipant?.isColorPickerVisible()??!1}_normalizedIndexToMarkdownHoverIndexRange(e,t){const i=this._renderedParts[t];if(!i||"hoverPart"!==i.type)return;if(!(i.participant===e))return;const s=this._renderedParts.findIndex((t=>"hoverPart"===t.type&&t.participant===e));if(-1===s)throw new U.D7;return t-s}get domNode(){return this._fragment}get domNodeHasChildren(){return this._fragment.hasChildNodes()}get focusedHoverPartIndex(){return this._focusedHoverPartIndex}}var V=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};let G=class extends n.jG{constructor(e,t,i){super(),this._editor=e,this._instantiationService=t,this._keybindingService=i,this._currentResult=null,this._onContentsChanged=this._register(new y.vl),this.onContentsChanged=this._onContentsChanged.event,this._contentHoverWidget=this._register(this._instantiationService.createInstance(L,this._editor)),this._participants=this._initializeHoverParticipants(),this._computer=new k(this._editor,this._participants),this._hoverOperation=this._register(new u.w(this._editor,this._computer)),this._registerListeners()}_initializeHoverParticipants(){const e=[];for(const t of g.B2.getAll()){const i=this._instantiationService.createInstance(t,this._editor);e.push(i)}return e.sort(((e,t)=>e.hoverOrdinal-t.hoverOrdinal)),this._register(this._contentHoverWidget.onDidResize((()=>{this._participants.forEach((e=>e.handleResize?.()))}))),e}_registerListeners(){this._register(this._hoverOperation.onResult((e=>{if(!this._computer.anchor)return;const t=e.hasLoadingMessage?this._addLoadingMessage(e.value):e.value;this._withResult(new A(this._computer.anchor,t,e.isComplete))})));const e=this._contentHoverWidget.getDomNode();this._register(h.b2(e,"keydown",(e=>{e.equals(9)&&this.hide()}))),this._register(h.b2(e,"mouseleave",(e=>{this._onMouseLeave(e)}))),this._register(d.dG.onDidChange((()=>{this._contentHoverWidget.position&&this._currentResult&&this._setCurrentResult(this._currentResult)})))}_startShowingOrUpdateHover(e,t,i,s,n){if(!(this._contentHoverWidget.position&&this._currentResult))return!!e&&(this._startHoverOperationIfNecessary(e,t,i,s,!1),!0);const r=this._editor.getOption(60).sticky,o=n&&this._contentHoverWidget.isMouseGettingCloser(n.event.posx,n.event.posy);if(r&&o)return e&&this._startHoverOperationIfNecessary(e,t,i,s,!0),!0;if(!e)return this._setCurrentResult(null),!1;if(this._currentResult.anchor.equals(e))return!0;return e.canAdoptVisibleHover(this._currentResult.anchor,this._contentHoverWidget.position)?(this._setCurrentResult(this._currentResult.filter(e)),this._startHoverOperationIfNecessary(e,t,i,s,!1),!0):(this._setCurrentResult(null),this._startHoverOperationIfNecessary(e,t,i,s,!1),!0)}_startHoverOperationIfNecessary(e,t,i,s,n){this._computer.anchor&&this._computer.anchor.equals(e)||(this._hoverOperation.cancel(),this._computer.anchor=e,this._computer.shouldFocus=s,this._computer.source=i,this._computer.insistOnKeepingHoverVisible=n,this._hoverOperation.start(t))}_setCurrentResult(e){let t=e;if(this._currentResult===t)return;t&&0===t.hoverParts.length&&(t=null),this._currentResult=t,this._currentResult?this._showHover(this._currentResult):this._hideHover()}_addLoadingMessage(e){if(!this._computer.anchor)return e;for(const t of this._participants){if(!t.createLoadingMessage)continue;const i=t.createLoadingMessage(this._computer.anchor);if(i)return e.slice(0).concat([i])}return e}_withResult(e){this._contentHoverWidget.position&&this._currentResult&&this._currentResult.isComplete||this._setCurrentResult(e);if(!e.isComplete)return;const t=0===e.hoverParts.length,i=this._computer.insistOnKeepingHoverVisible;t&&i||this._setCurrentResult(e)}_showHover(e){const t=this._getHoverContext();this._renderedContentHover=new H(this._editor,e,this._participants,this._computer,t,this._keybindingService),this._renderedContentHover.domNodeHasChildren?this._contentHoverWidget.show(this._renderedContentHover):this._renderedContentHover.dispose()}_hideHover(){this._contentHoverWidget.hide()}_getHoverContext(){return{hide:()=>{this.hide()},onContentsChanged:()=>{this._onContentsChanged.fire(),this._contentHoverWidget.onContentsChanged()},setMinimumDimensions:e=>{this._contentHoverWidget.setMinimumDimensions(e)}}}showsOrWillShow(e){if(this._contentHoverWidget.isResizing)return!0;const t=this._findHoverAnchorCandidates(e);if(!(t.length>0))return this._startShowingOrUpdateHover(null,0,0,!1,e);const i=t[0];return this._startShowingOrUpdateHover(i,0,0,!1,e)}_findHoverAnchorCandidates(e){const t=[];for(const s of this._participants){if(!s.suggestHoverAnchor)continue;const i=s.suggestHoverAnchor(e);i&&t.push(i)}const i=e.target;switch(i.type){case 6:t.push(new g.hx(0,i.range,e.event.posx,e.event.posy));break;case 7:{const s=this._editor.getOption(50).typicalHalfwidthCharacterWidth/2;if(!(!i.detail.isAfterLines&&"number"===typeof i.detail.horizontalDistanceToText&&i.detail.horizontalDistanceToTextt.priority-e.priority)),t}_onMouseLeave(e){const t=this._editor.getDomNode();(!t||!(0,l.U)(t,e.x,e.y))&&this.hide()}startShowingAtRange(e,t,i,s){this._startShowingOrUpdateHover(new g.hx(0,e,void 0,void 0),t,i,s,null)}async updateHoverVerbosityLevel(e,t,i){this._renderedContentHover?.updateHoverVerbosityLevel(e,t,i)}focusedHoverPartIndex(){return this._renderedContentHover?.focusedHoverPartIndex??-1}containsNode(e){return!!e&&this._contentHoverWidget.getDomNode().contains(e)}focus(){this._contentHoverWidget.focus()}scrollUp(){this._contentHoverWidget.scrollUp()}scrollDown(){this._contentHoverWidget.scrollDown()}scrollLeft(){this._contentHoverWidget.scrollLeft()}scrollRight(){this._contentHoverWidget.scrollRight()}pageUp(){this._contentHoverWidget.pageUp()}pageDown(){this._contentHoverWidget.pageDown()}goToTop(){this._contentHoverWidget.goToTop()}goToBottom(){this._contentHoverWidget.goToBottom()}hide(){this._computer.anchor=null,this._hoverOperation.cancel(),this._setCurrentResult(null)}getDomNode(){return this._contentHoverWidget.getDomNode()}get isColorPickerVisible(){return this._renderedContentHover?.isColorPickerVisible()??!1}get isVisibleFromKeyboard(){return this._contentHoverWidget.isVisibleFromKeyboard}get isVisible(){return this._contentHoverWidget.isVisible}get isFocused(){return this._contentHoverWidget.isFocused}get isResizing(){return this._contentHoverWidget.isResizing}get widget(){return this._contentHoverWidget}};G=V([z(1,r._Y),z(2,a.b)],G);i(82320);var j,K=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Y=function(e,t){return function(i,s){t(i,s,e)}};let q=class extends n.jG{static{j=this}static{this.ID="editor.contrib.contentHover"}constructor(e,t,i){super(),this._editor=e,this._instantiationService=t,this._keybindingService=i,this._onHoverContentsChanged=this._register(new y.vl),this.shouldKeepOpenOnEditorMouseMoveOrLeave=!1,this._listenersStore=new n.Cm,this._hoverState={mouseDown:!1,activatedByDecoratorClick:!1},this._reactToEditorMouseMoveRunner=this._register(new c.uC((()=>this._reactToEditorMouseMove(this._mouseMoveEvent)),0)),this._hookListeners(),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(60)&&(this._unhookListeners(),this._hookListeners())})))}static get(e){return e.getContribution(j.ID)}_hookListeners(){const e=this._editor.getOption(60);this._hoverSettings={enabled:e.enabled,sticky:e.sticky,hidingDelay:e.hidingDelay},e.enabled?(this._listenersStore.add(this._editor.onMouseDown((e=>this._onEditorMouseDown(e)))),this._listenersStore.add(this._editor.onMouseUp((()=>this._onEditorMouseUp()))),this._listenersStore.add(this._editor.onMouseMove((e=>this._onEditorMouseMove(e)))),this._listenersStore.add(this._editor.onKeyDown((e=>this._onKeyDown(e))))):(this._listenersStore.add(this._editor.onMouseMove((e=>this._onEditorMouseMove(e)))),this._listenersStore.add(this._editor.onKeyDown((e=>this._onKeyDown(e))))),this._listenersStore.add(this._editor.onMouseLeave((e=>this._onEditorMouseLeave(e)))),this._listenersStore.add(this._editor.onDidChangeModel((()=>{this._cancelScheduler(),this._hideWidgets()}))),this._listenersStore.add(this._editor.onDidChangeModelContent((()=>this._cancelScheduler()))),this._listenersStore.add(this._editor.onDidScrollChange((e=>this._onEditorScrollChanged(e))))}_unhookListeners(){this._listenersStore.clear()}_cancelScheduler(){this._mouseMoveEvent=void 0,this._reactToEditorMouseMoveRunner.cancel()}_onEditorScrollChanged(e){(e.scrollTopChanged||e.scrollLeftChanged)&&this._hideWidgets()}_onEditorMouseDown(e){this._hoverState.mouseDown=!0;this._shouldNotHideCurrentHoverWidget(e)||this._hideWidgets()}_shouldNotHideCurrentHoverWidget(e){return this._isMouseOnContentHoverWidget(e)||this._isContentWidgetResizing()}_isMouseOnContentHoverWidget(e){const t=this._contentWidget?.getDomNode();return!!t&&(0,l.U)(t,e.event.posx,e.event.posy)}_onEditorMouseUp(){this._hoverState.mouseDown=!1}_onEditorMouseLeave(e){if(this.shouldKeepOpenOnEditorMouseMoveOrLeave)return;this._cancelScheduler();this._shouldNotHideCurrentHoverWidget(e)||this._hideWidgets()}_shouldNotRecomputeCurrentHoverWidget(e){const t=this._hoverSettings.sticky;return((e,t)=>{const i=this._isMouseOnContentHoverWidget(e);return t&&i})(e,t)||(e=>{const t=this._isMouseOnContentHoverWidget(e),i=this._contentWidget?.isColorPickerVisible??!1;return t&&i})(e)||((e,t)=>(t&&this._contentWidget?.containsNode(e.event.browserEvent.view?.document.activeElement)&&!e.event.browserEvent.view?.getSelection()?.isCollapsed)??!1)(e,t)}_onEditorMouseMove(e){if(this.shouldKeepOpenOnEditorMouseMoveOrLeave)return;if(this._mouseMoveEvent=e,this._contentWidget?.isFocused||this._contentWidget?.isResizing)return;const t=this._hoverSettings.sticky;if(t&&this._contentWidget?.isVisibleFromKeyboard)return;if(this._shouldNotRecomputeCurrentHoverWidget(e))return void this._reactToEditorMouseMoveRunner.cancel();const i=this._hoverSettings.hidingDelay,s=this._contentWidget?.isVisible;s&&t&&i>0?this._reactToEditorMouseMoveRunner.isScheduled()||this._reactToEditorMouseMoveRunner.schedule(i):this._reactToEditorMouseMove(e)}_reactToEditorMouseMove(e){if(!e)return;const t=e.target,i=t.element?.classList.contains("colorpicker-color-decoration"),s=this._editor.getOption(149),n=this._hoverSettings.enabled,r=this._hoverState.activatedByDecoratorClick;if(i&&("click"===s&&!r||"hover"===s&&!n||"clickAndHover"===s&&!n&&!r)||!i&&!n&&!r)return void this._hideWidgets();this._tryShowHoverWidget(e)||this._hideWidgets()}_tryShowHoverWidget(e){return this._getOrCreateContentWidget().showsOrWillShow(e)}_onKeyDown(e){if(!this._editor.hasModel())return;const t=this._keybindingService.softDispatch(e,this._editor.getDomNode()),i=1===t.kind||2===t.kind&&(t.commandId===s.jA||t.commandId===s.jq||t.commandId===s.Zp)&&this._contentWidget?.isVisible;5===e.keyCode||6===e.keyCode||57===e.keyCode||4===e.keyCode||i||this._hideWidgets()}_hideWidgets(){this._hoverState.mouseDown&&this._contentWidget?.isColorPickerVisible||o.bo.dropDownVisible||(this._hoverState.activatedByDecoratorClick=!1,this._contentWidget?.hide())}_getOrCreateContentWidget(){return this._contentWidget||(this._contentWidget=this._instantiationService.createInstance(G,this._editor),this._listenersStore.add(this._contentWidget.onContentsChanged((()=>this._onHoverContentsChanged.fire())))),this._contentWidget}showContentHover(e,t,i,s,n=!1){this._hoverState.activatedByDecoratorClick=n,this._getOrCreateContentWidget().startShowingAtRange(e,t,i,s)}_isContentWidgetResizing(){return this._contentWidget?.widget.isResizing||!1}focusedHoverPartIndex(){return this._getOrCreateContentWidget().focusedHoverPartIndex()}updateHoverVerbosityLevel(e,t,i){this._getOrCreateContentWidget().updateHoverVerbosityLevel(e,t,i)}focus(){this._contentWidget?.focus()}scrollUp(){this._contentWidget?.scrollUp()}scrollDown(){this._contentWidget?.scrollDown()}scrollLeft(){this._contentWidget?.scrollLeft()}scrollRight(){this._contentWidget?.scrollRight()}pageUp(){this._contentWidget?.pageUp()}pageDown(){this._contentWidget?.pageDown()}goToTop(){this._contentWidget?.goToTop()}goToBottom(){this._contentWidget?.goToBottom()}get isColorPickerVisible(){return this._contentWidget?.isColorPickerVisible}get isHoverVisible(){return this._contentWidget?.isVisible}dispose(){super.dispose(),this._unhookListeners(),this._listenersStore.dispose(),this._contentWidget?.dispose()}};q=j=K([Y(1,r._Y),Y(2,a.b)],q)},77047:(e,t,i)=>{"use strict";var s=i(46359),n=i(71597),r=i(51861),o=i(80301),a=i(37882),c=i(73983),l=i(70125),h=i(64383),d=i(26690),u=i(6921),g=i(5662),p=i(74320);class m{constructor(){this.chunkCount=0,this.chunkOccurrences=new Map,this.documents=new Map}calculateScores(e,t){const i=this.computeEmbedding(e),s=new Map,n=[];for(const[r,o]of this.documents){if(t.isCancellationRequested)return[];for(const e of o.chunks){const t=this.computeSimilarityScore(e,i,s);t>0&&n.push({key:r,score:t})}}return n}static termFrequencies(e){return function(e){const t=new Map;for(const i of e)t.set(i,(t.get(i)??0)+1);return t}(m.splitTerms(e))}static*splitTerms(e){const t=e=>e.toLowerCase();for(const[i]of e.matchAll(/\b\p{Letter}[\p{Letter}\d]{2,}\b/gu)){yield t(i);const e=i.replace(/([a-z])([A-Z])/g,"$1 $2").split(/\s+/g);if(e.length>1)for(const i of e)i.length>2&&/\p{Letter}{3,}/gu.test(i)&&(yield t(i))}}updateDocuments(e){for(const{key:t}of e)this.deleteDocument(t);for(const t of e){const e=[];for(const i of t.textChunks){const t=m.termFrequencies(i);for(const e of t.keys())this.chunkOccurrences.set(e,(this.chunkOccurrences.get(e)??0)+1);e.push({text:i,tf:t})}this.chunkCount+=e.length,this.documents.set(t.key,{chunks:e})}return this}deleteDocument(e){const t=this.documents.get(e);if(t){this.documents.delete(e),this.chunkCount-=t.chunks.length;for(const e of t.chunks)for(const t of e.tf.keys()){const e=this.chunkOccurrences.get(t);if("number"===typeof e){const i=e-1;i<=0?this.chunkOccurrences.delete(t):this.chunkOccurrences.set(t,i)}}}}computeSimilarityScore(e,t,i){let s=0;for(const[n,r]of Object.entries(t)){const t=e.tf.get(n);if(!t)continue;let o=i.get(n);"number"!==typeof o&&(o=this.computeIdf(n),i.set(n,o));s+=t*o*r}return s}computeEmbedding(e){const t=m.termFrequencies(e);return this.computeTfidf(t)}computeIdf(e){const t=this.chunkOccurrences.get(e)??0;return t>0?Math.log((this.chunkCount+1)/t):0}computeTfidf(e){const t=Object.create(null);for(const[i,s]of e){const e=this.computeIdf(i);e>0&&(t[i]=s*e)}return t}}var f,_=i(78209),v=i(50091),C=i(84001),E=i(59599),b=i(63591),S=i(98031),y=i(18801),w=i(90766),R=i(18447),L=i(631);function T(e){const t=e;return Array.isArray(t.items)}function x(e){const t=e;return!!t.picks&&t.additionalPicks instanceof Promise}!function(e){e[e.NO_ACTION=0]="NO_ACTION",e[e.CLOSE_PICKER=1]="CLOSE_PICKER",e[e.REFRESH_PICKER=2]="REFRESH_PICKER",e[e.REMOVE_ITEM=3]="REMOVE_ITEM"}(f||(f={}));class k extends g.jG{constructor(e,t){super(),this.prefix=e,this.options=t}provide(e,t,i){const s=new g.Cm;let n;e.canAcceptInBackground=!!this.options?.canAcceptInBackground,e.matchOnLabel=e.matchOnDescription=e.matchOnDetail=e.sortByLabel=!1;const r=s.add(new g.HE),o=async()=>{const s=r.value=new g.Cm;n?.dispose(!0),e.busy=!1,n=new R.Qi(t);const o=n.token;let a=e.value.substring(this.prefix.length);this.options?.shouldSkipTrimPickFilter||(a=a.trim());const c=this._getPicks(a,s,o,i),l=(t,i)=>{let s,n;if(T(t)?(s=t.items,n=t.active):s=t,0===s.length){if(i)return!1;(a.length>0||e.hideInput)&&this.options?.noResultsPick&&(s=(0,L.Tn)(this.options.noResultsPick)?[this.options.noResultsPick(a)]:[this.options.noResultsPick])}return e.items=s,n&&(e.activeItems=[n]),!0},h=async t=>{let i=!1,s=!1;await Promise.all([(async()=>{"number"===typeof t.mergeDelay&&(await(0,w.wR)(t.mergeDelay),o.isCancellationRequested)||s||(i=l(t.picks,!0))})(),(async()=>{e.busy=!0;try{const s=await t.additionalPicks;if(o.isCancellationRequested)return;let n,r,a,c;if(T(t.picks)?(n=t.picks.items,r=t.picks.active):n=t.picks,T(s)?(a=s.items,c=s.active):a=s,a.length>0||!i){let t;if(!r&&!c){const i=e.activeItems[0];i&&-1!==n.indexOf(i)&&(t=i)}l({items:[...n,...a],active:r||c||t})}}finally{o.isCancellationRequested||(e.busy=!1),s=!0}})()])};if(null===c);else if(x(c))await h(c);else if(c instanceof Promise){e.busy=!0;try{const e=await c;if(o.isCancellationRequested)return;x(e)?await h(e):l(e)}finally{o.isCancellationRequested||(e.busy=!1)}}else l(c)};s.add(e.onDidChangeValue((()=>o()))),o(),s.add(e.onDidAccept((t=>{if(i?.handleAccept)return t.inBackground||e.hide(),void i.handleAccept?.(e.activeItems[0]);const[s]=e.selectedItems;"function"===typeof s?.accept&&(t.inBackground||e.hide(),s.accept(e.keyMods,t))})));const a=async(i,s)=>{if("function"!==typeof s.trigger)return;const n=s.buttons?.indexOf(i)??-1;if(n>=0){const i=s.trigger(n,e.keyMods),r="number"===typeof i?i:await i;if(t.isCancellationRequested)return;switch(r){case f.NO_ACTION:break;case f.CLOSE_PICKER:e.hide();break;case f.REFRESH_PICKER:o();break;case f.REMOVE_ITEM:{const t=e.items.indexOf(s);if(-1!==t){const i=e.items.slice(),s=i.splice(t,1),n=e.activeItems.filter((e=>e!==s[0])),r=e.keepScrollPosition;e.keepScrollPosition=!0,e.items=i,n&&(e.activeItems=n),e.keepScrollPosition=r}break}}}};return s.add(e.onDidTriggerItemButton((({button:e,item:t})=>a(e,t)))),s.add(e.onDidTriggerSeparatorButton((({button:e,separator:t})=>a(e,t)))),s}}var A,N,I=i(9711),O=i(90651),D=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},M=function(e,t){return function(i,s){t(i,s,e)}};let P=class extends k{static{A=this}static{this.PREFIX=">"}static{this.TFIDF_THRESHOLD=.5}static{this.TFIDF_MAX_RESULTS=5}static{this.WORD_FILTER=(0,d.or)(d.WP,d.J1,d.Tt)}constructor(e,t,i,s,n,r){super(A.PREFIX,e),this.instantiationService=t,this.keybindingService=i,this.commandService=s,this.telemetryService=n,this.dialogService=r,this.commandsHistory=this._register(this.instantiationService.createInstance(F)),this.options=e}async _getPicks(e,t,i,s){const n=await this.getCommandPicks(i);if(i.isCancellationRequested)return[];const r=(0,u.P)((()=>{const t=new m;t.updateDocuments(n.map((e=>({key:e.commandId,textChunks:[this.getTfIdfChunk(e)]}))));return function(e){const t=e.slice(0);t.sort(((e,t)=>t.score-e.score));const i=t[0]?.score??0;if(i>0)for(const s of t)s.score/=i;return t}(t.calculateScores(e,i)).filter((e=>e.score>A.TFIDF_THRESHOLD)).slice(0,A.TFIDF_MAX_RESULTS)})),o=[];for(const u of n){const t=A.WORD_FILTER(e,u.label)??void 0,s=u.commandAlias?A.WORD_FILTER(e,u.commandAlias)??void 0:void 0;if(t||s)u.highlights={label:t,detail:this.options.showAlias?s:void 0},o.push(u);else if(e===u.commandId)o.push(u);else if(e.length>=3){const e=r();if(i.isCancellationRequested)return[];const t=e.find((e=>e.key===u.commandId));t&&(u.tfIdfScore=t.score,o.push(u))}}const a=new Map;for(const u of o){const e=a.get(u.label);e?(u.description=u.commandId,e.description=e.commandId):a.set(u.label,u)}o.sort(((e,t)=>{if(e.tfIdfScore&&t.tfIdfScore)return e.tfIdfScore===t.tfIdfScore?e.label.localeCompare(t.label):t.tfIdfScore-e.tfIdfScore;if(e.tfIdfScore)return 1;if(t.tfIdfScore)return-1;const i=this.commandsHistory.peek(e.commandId),s=this.commandsHistory.peek(t.commandId);if(i&&s)return i>s?-1:1;if(i)return-1;if(s)return 1;if(this.options.suggestedCommandIds){const i=this.options.suggestedCommandIds.has(e.commandId),s=this.options.suggestedCommandIds.has(t.commandId);if(i&&s)return 0;if(i)return-1;if(s)return 1}return e.label.localeCompare(t.label)}));const c=[];let l=!1,h=!0,d=!!this.options.suggestedCommandIds;for(let u=0;u{const t=await this.getAdditionalCommandPicks(n,o,e,i);if(i.isCancellationRequested)return[];const r=t.map((e=>this.toCommandPick(e,s)));return h&&"separator"!==r[0]?.type&&r.unshift({type:"separator",label:(0,_.kg)("suggested","similar commands")}),r})()}:c}toCommandPick(e,t){if("separator"===e.type)return e;const i=this.keybindingService.lookupKeybinding(e.commandId),s=i?(0,_.kg)("commandPickAriaLabelWithKeybinding","{0}, {1}",e.label,i.getAriaLabel()):e.label;return{...e,ariaLabel:s,detail:this.options.showAlias&&e.commandAlias!==e.label?e.commandAlias:void 0,keybinding:i,accept:async()=>{this.commandsHistory.push(e.commandId),this.telemetryService.publicLog2("workbenchActionExecuted",{id:e.commandId,from:t?.from??"quick open"});try{e.args?.length?await this.commandService.executeCommand(e.commandId,...e.args):await this.commandService.executeCommand(e.commandId)}catch(i){(0,h.MB)(i)||this.dialogService.error((0,_.kg)("canNotRun","Command '{0}' resulted in an error",e.label),(0,l.r)(i))}}}}getTfIdfChunk({label:e,commandAlias:t,commandDescription:i}){let s=e;return t&&t!==e&&(s+=` - ${t}`),i&&i.value!==e&&(s+=` - ${i.value===i.original?i.value:`${i.value} (${i.original})`}`),s}};P=A=D([M(1,b._Y),M(2,S.b),M(3,v.d),M(4,O.k),M(5,E.X)],P);let F=class extends g.jG{static{N=this}static{this.DEFAULT_COMMANDS_HISTORY_LENGTH=50}static{this.PREF_KEY_CACHE="commandPalette.mru.cache"}static{this.PREF_KEY_COUNTER="commandPalette.mru.counter"}static{this.counter=1}static{this.hasChanges=!1}constructor(e,t,i){super(),this.storageService=e,this.configurationService=t,this.logService=i,this.configuredCommandsHistoryLength=0,this.updateConfiguration(),this.load(),this.registerListeners()}registerListeners(){this._register(this.configurationService.onDidChangeConfiguration((e=>this.updateConfiguration(e)))),this._register(this.storageService.onWillSaveState((e=>{e.reason===I.LP.SHUTDOWN&&this.saveState()})))}updateConfiguration(e){e&&!e.affectsConfiguration("workbench.commandPalette.history")||(this.configuredCommandsHistoryLength=N.getConfiguredCommandHistoryLength(this.configurationService),N.cache&&N.cache.limit!==this.configuredCommandsHistoryLength&&(N.cache.limit=this.configuredCommandsHistoryLength,N.hasChanges=!0))}load(){const e=this.storageService.get(N.PREF_KEY_CACHE,0);let t;if(e)try{t=JSON.parse(e)}catch(s){this.logService.error(`[CommandsHistory] invalid data: ${s}`)}const i=N.cache=new p.qK(this.configuredCommandsHistoryLength,1);if(t){let e;e=t.usesLRU?t.entries:t.entries.sort(((e,t)=>e.value-t.value)),e.forEach((e=>i.set(e.key,e.value)))}N.counter=this.storageService.getNumber(N.PREF_KEY_COUNTER,0,N.counter)}push(e){N.cache&&(N.cache.set(e,N.counter++),N.hasChanges=!0)}peek(e){return N.cache?.peek(e)}saveState(){if(!N.cache)return;if(!N.hasChanges)return;const e={usesLRU:!0,entries:[]};N.cache.forEach(((t,i)=>e.entries.push({key:i,value:t}))),this.storageService.store(N.PREF_KEY_CACHE,JSON.stringify(e),0,0),this.storageService.store(N.PREF_KEY_COUNTER,N.counter,0,0),N.hasChanges=!1}static getConfiguredCommandHistoryLength(e){const t=e.getValue(),i=t.workbench?.commandPalette?.history;return"number"===typeof i?i:N.DEFAULT_COMMANDS_HISTORY_LENGTH}};F=N=D([M(0,I.CS),M(1,C.pG),M(2,y.rr)],F);class U extends P{constructor(e,t,i,s,n,r){super(e,t,i,s,n,r)}getCodeEditorCommandPicks(){const e=this.activeTextEditorControl;if(!e)return[];const t=[];for(const i of e.getSupportedActions()){let e;i.metadata?.description&&(e=(0,c.f)(i.metadata.description)?i.metadata.description:{original:i.metadata.description,value:i.metadata.description}),t.push({commandId:i.id,commandAlias:i.alias,commandDescription:e,label:(0,a.pS)(i.label)||i.id})}return t}}var H=i(31450),B=i(60002),W=i(51467),V=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};let G=class extends U{get activeTextEditorControl(){return this.codeEditorService.getFocusedCodeEditor()??void 0}constructor(e,t,i,s,n,r){super({showAlias:!1},e,i,s,n,r),this.codeEditorService=t}async getCommandPicks(){return this.getCodeEditorCommandPicks()}hasAdditionalCommandPicks(){return!1}async getAdditionalCommandPicks(){return[]}};G=V([z(0,b._Y),z(1,o.T),z(2,S.b),z(3,v.d),z(4,O.k),z(5,E.X)],G);class j extends H.ks{static{this.ID="editor.action.quickCommand"}constructor(){super({id:j.ID,label:r.gf.quickCommandActionLabel,alias:"Command Palette",precondition:void 0,kbOpts:{kbExpr:B.R.focus,primary:59,weight:100},contextMenuOpts:{group:"z_commands",order:1}})}run(e){e.get(W.GK).quickAccess.show(G.PREFIX)}}(0,H.Fl)(j),s.O.as(n.Fd.Quickaccess).registerQuickAccessProvider({ctor:G,prefix:G.PREFIX,helpEntries:[{description:r.gf.quickCommandHelp,commandId:j.ID}]})},77163:(e,t,i)=>{"use strict";i.d(t,{M:()=>n});var s=i(41234);const n=new class{constructor(){this._tabFocus=!1,this._onDidChangeTabFocus=new s.vl,this.onDidChangeTabFocus=this._onDidChangeTabFocus.event}getTabFocusMode(){return this._tabFocus}setTabFocusMode(e){this._tabFocus=e,this._onDidChangeTabFocus.fire(this._tabFocus)}}},77668:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sql",extensions:[".sql"],aliases:["SQL"],loader:()=>i.e(49778).then(i.bind(i,49778))})},77888:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"clojure",extensions:[".clj",".cljs",".cljc",".edn"],aliases:["clojure","Clojure"],loader:()=>i.e(57206).then(i.bind(i,57206))})},78049:(e,t,i)=>{"use strict";function s(e,t){let i=0,s=0;const n=e.length;for(;ss})},78209:(e,t,i)=>{"use strict";function s(){return globalThis._VSCODE_NLS_MESSAGES}function n(){return globalThis._VSCODE_NLS_LANGUAGE}i.d(t,{i8:()=>n,Ec:()=>s,kg:()=>a,aS:()=>l});const r="pseudo"===n()||"undefined"!==typeof document&&document.location&&document.location.hash.indexOf("pseudo=true")>=0;function o(e,t){let i;return i=0===t.length?e:e.replace(/\{(\d+)\}/g,((e,i)=>{const s=i[0],n=t[s];let r=e;return"string"===typeof n?r=n:"number"!==typeof n&&"boolean"!==typeof n&&void 0!==n&&null!==n||(r=String(n)),r})),r&&(i="\uff3b"+i.replace(/[aouei]/g,"$&$&")+"\uff3d"),i}function a(e,t,...i){return o("number"===typeof e?c(e,t):t,i)}function c(e,t){const i=s()?.[e];if("string"!==typeof i){if("string"===typeof t)return t;throw new Error(`!!! NLS MISSING: ${e} !!!`)}return i}function l(e,t,...i){let s;s="number"===typeof e?c(e,t):t;const n=o(s,i);return{value:n,original:t===s?n:o(t,i)}}},78244:(e,t,i)=>{"use strict";i.d(t,{PA:()=>r,Vl:()=>n,Wt:()=>s});const s="editor.action.inlineSuggest.commit",n="editor.action.inlineSuggest.showPrevious",r="editor.action.inlineSuggest.showNext"},78381:(e,t,i)=>{"use strict";i.d(t,{W:()=>n});const s=globalThis.performance&&"function"===typeof globalThis.performance.now;class n{static create(e){return new n(e)}constructor(e){this._now=s&&!1===e?Date.now:globalThis.performance.now.bind(globalThis.performance),this._startTime=this._now(),this._stopTime=-1}stop(){this._stopTime=this._now()}reset(){this._startTime=this._now(),this._stopTime=-1}elapsed(){return-1!==this._stopTime?this._stopTime-this._startTime:this._now()-this._startTime}}},78748:(e,t,i)=>{"use strict";i.d(t,{F:()=>r});var s=i(41234),n=i(46359);const r={JSONContribution:"base.contributions.json"};const o=new class{constructor(){this._onDidChangeSchema=new s.vl,this.schemasById={}}registerSchema(e,t){var i;this.schemasById[(i=e,i.length>0&&"#"===i.charAt(i.length-1)?i.substring(0,i.length-1):i)]=t,this._onDidChangeSchema.fire(e)}notifySchemaChanged(e){this._onDidChangeSchema.fire(e)}};n.O.add(r.JSONContribution,o)},79027:(e,t,i)=>{"use strict";i.d(t,{D:()=>n});var s=i(41234);const n=new class{constructor(){this._zoomLevel=0,this._onDidChangeZoomLevel=new s.vl,this.onDidChangeZoomLevel=this._onDidChangeZoomLevel.event}getZoomLevel(){return this._zoomLevel}setZoomLevel(e){e=Math.min(Math.max(-5,e),20),this._zoomLevel!==e&&(this._zoomLevel=e,this._onDidChangeZoomLevel.fire(this._zoomLevel))}}},79064:(e,t,i)=>{var s=i(59368),n=i(63819);e.exports=function e(t,i,r,o,a){var c=-1,l=t.length;for(r||(r=n),a||(a=[]);++c0&&r(h)?i>1?e(h,i-1,r,o,a):s(a,h):o||(a[a.length]=h)}return a}},79326:(e,t,i)=>{"use strict";i.d(t,{No:()=>u,TH:()=>a,Zn:()=>l,_1:()=>h,kb:()=>c});var s=i(74027),n=i(98067),r=i(91508);function o(e){return 47===e||92===e}function a(e){return e.replace(/[\\/]/g,s.SA.sep)}function c(e){return-1===e.indexOf("/")&&(e=a(e)),/^[a-zA-Z]:(\/|$)/.test(e)&&(e="/"+e),e}function l(e,t=s.SA.sep){if(!e)return"";const i=e.length,n=e.charCodeAt(0);if(o(n)){if(o(e.charCodeAt(1))&&!o(e.charCodeAt(2))){let s=3;const n=s;for(;se.length)return!1;if(i){if(!(0,r.ns)(e,t))return!1;if(t.length===e.length)return!0;let i=t.length;return t.charAt(t.length-1)===n&&i--,e.charAt(i)===n}return t.charAt(t.length-1)!==n&&(t+=n),0===e.indexOf(t)}function d(e){return e>=65&&e<=90||e>=97&&e<=122}function u(e,t=n.uF){return!!t&&(d(e.charCodeAt(0))&&58===e.charCodeAt(1))}},79400:(e,t,i)=>{"use strict";i.d(t,{I:()=>_,r:()=>d});var s=i(74027),n=i(98067);const r=/^\w[\w\d+.-]*$/,o=/^\//,a=/^\/\//;const c="",l="/",h=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/;class d{static isUri(e){return e instanceof d||!!e&&("string"===typeof e.authority&&"string"===typeof e.fragment&&"string"===typeof e.path&&"string"===typeof e.query&&"string"===typeof e.scheme&&"string"===typeof e.fsPath&&"function"===typeof e.with&&"function"===typeof e.toString)}constructor(e,t,i,s,n,h=!1){"object"===typeof e?(this.scheme=e.scheme||c,this.authority=e.authority||c,this.path=e.path||c,this.query=e.query||c,this.fragment=e.fragment||c):(this.scheme=function(e,t){return e||t?e:"file"}(e,h),this.authority=t||c,this.path=function(e,t){switch(e){case"https":case"http":case"file":t?t[0]!==l&&(t=l+t):t=l}return t}(this.scheme,i||c),this.query=s||c,this.fragment=n||c,function(e,t){if(!e.scheme&&t)throw new Error(`[UriError]: Scheme is missing: {scheme: "", authority: "${e.authority}", path: "${e.path}", query: "${e.query}", fragment: "${e.fragment}"}`);if(e.scheme&&!r.test(e.scheme))throw new Error("[UriError]: Scheme contains illegal characters.");if(e.path)if(e.authority){if(!o.test(e.path))throw new Error('[UriError]: If a URI contains an authority component, then the path component must either be empty or begin with a slash ("/") character')}else if(a.test(e.path))throw new Error('[UriError]: If a URI does not contain an authority component, then the path cannot begin with two slash characters ("//")')}(this,h))}get fsPath(){return _(this,!1)}with(e){if(!e)return this;let{scheme:t,authority:i,path:s,query:n,fragment:r}=e;return void 0===t?t=this.scheme:null===t&&(t=c),void 0===i?i=this.authority:null===i&&(i=c),void 0===s?s=this.path:null===s&&(s=c),void 0===n?n=this.query:null===n&&(n=c),void 0===r?r=this.fragment:null===r&&(r=c),t===this.scheme&&i===this.authority&&s===this.path&&n===this.query&&r===this.fragment?this:new g(t,i,s,n,r)}static parse(e,t=!1){const i=h.exec(e);return i?new g(i[2]||c,b(i[4]||c),b(i[5]||c),b(i[7]||c),b(i[9]||c),t):new g(c,c,c,c,c)}static file(e){let t=c;if(n.uF&&(e=e.replace(/\\/g,l)),e[0]===l&&e[1]===l){const i=e.indexOf(l,2);-1===i?(t=e.substring(2),e=l):(t=e.substring(2,i),e=e.substring(i)||l)}return new g("file",t,e,c,c)}static from(e,t){return new g(e.scheme,e.authority,e.path,e.query,e.fragment,t)}static joinPath(e,...t){if(!e.path)throw new Error("[UriError]: cannot call joinPath on URI without path");let i;return i=n.uF&&"file"===e.scheme?d.file(s.IN.join(_(e,!0),...t)).path:s.SA.join(e.path,...t),e.with({path:i})}toString(e=!1){return v(this,e)}toJSON(){return this}static revive(e){if(e){if(e instanceof d)return e;{const t=new g(e);return t._formatted=e.external??null,t._fsPath=e._sep===u?e.fsPath??null:null,t}}return e}}const u=n.uF?1:void 0;class g extends d{constructor(){super(...arguments),this._formatted=null,this._fsPath=null}get fsPath(){return this._fsPath||(this._fsPath=_(this,!1)),this._fsPath}toString(e=!1){return e?v(this,!0):(this._formatted||(this._formatted=v(this,!1)),this._formatted)}toJSON(){const e={$mid:1};return this._fsPath&&(e.fsPath=this._fsPath,e._sep=u),this._formatted&&(e.external=this._formatted),this.path&&(e.path=this.path),this.scheme&&(e.scheme=this.scheme),this.authority&&(e.authority=this.authority),this.query&&(e.query=this.query),this.fragment&&(e.fragment=this.fragment),e}}const p={58:"%3A",47:"%2F",63:"%3F",35:"%23",91:"%5B",93:"%5D",64:"%40",33:"%21",36:"%24",38:"%26",39:"%27",40:"%28",41:"%29",42:"%2A",43:"%2B",44:"%2C",59:"%3B",61:"%3D",32:"%20"};function m(e,t,i){let s,n=-1;for(let r=0;r=97&&o<=122||o>=65&&o<=90||o>=48&&o<=57||45===o||46===o||95===o||126===o||t&&47===o||i&&91===o||i&&93===o||i&&58===o)-1!==n&&(s+=encodeURIComponent(e.substring(n,r)),n=-1),void 0!==s&&(s+=e.charAt(r));else{void 0===s&&(s=e.substr(0,r));const t=p[o];void 0!==t?(-1!==n&&(s+=encodeURIComponent(e.substring(n,r)),n=-1),s+=t):-1===n&&(n=r)}}return-1!==n&&(s+=encodeURIComponent(e.substring(n))),void 0!==s?s:e}function f(e){let t;for(let i=0;i1&&"file"===e.scheme?`//${e.authority}${e.path}`:47===e.path.charCodeAt(0)&&(e.path.charCodeAt(1)>=65&&e.path.charCodeAt(1)<=90||e.path.charCodeAt(1)>=97&&e.path.charCodeAt(1)<=122)&&58===e.path.charCodeAt(2)?t?e.path.substr(1):e.path[1].toLowerCase()+e.path.substr(2):e.path,n.uF&&(i=i.replace(/\//g,"\\")),i}function v(e,t){const i=t?f:m;let s="",{scheme:n,authority:r,path:o,query:a,fragment:c}=e;if(n&&(s+=n,s+=":"),(r||"file"===n)&&(s+=l,s+=l),r){let e=r.indexOf("@");if(-1!==e){const t=r.substr(0,e);r=r.substr(e+1),e=t.lastIndexOf(":"),-1===e?s+=i(t,!1,!1):(s+=i(t.substr(0,e),!1,!1),s+=":",s+=i(t.substr(e+1),!1,!0)),s+="@"}r=r.toLowerCase(),e=r.lastIndexOf(":"),-1===e?s+=i(r,!1,!0):(s+=i(r.substr(0,e),!1,!0),s+=r.substr(e))}if(o){if(o.length>=3&&47===o.charCodeAt(0)&&58===o.charCodeAt(2)){const e=o.charCodeAt(1);e>=65&&e<=90&&(o=`/${String.fromCharCode(e+32)}:${o.substr(3)}`)}else if(o.length>=2&&58===o.charCodeAt(1)){const e=o.charCodeAt(0);e>=65&&e<=90&&(o=`${String.fromCharCode(e+32)}:${o.substr(2)}`)}s+=i(o,!0,!1)}return a&&(s+="?",s+=i(a,!1,!1)),c&&(s+="#",s+=t?c:m(c,!1,!1)),s}function C(e){try{return decodeURIComponent(e)}catch{return e.length>3?e.substr(0,3)+C(e.substr(3)):e}}const E=/(%[0-9A-Za-z][0-9A-Za-z])+/g;function b(e){return e.match(E)?e.replace(E,(e=>C(e))):e}},79614:(e,t,i)=>{"use strict";i.d(t,{$L:()=>p,y4:()=>m,yc:()=>u});var s=i(64383),n=i(41234),r=i(96032),o=i(5662),a=i(74320),c=i(89403),l=i(91508),h=i(36677),d=i(78209);class u{constructor(e,t,i,s){this.isProviderFirst=e,this.parent=t,this.link=i,this._rangeCallback=s,this.id=r.r.nextId()}get uri(){return this.link.uri}get range(){return this._range??this.link.targetSelectionRange??this.link.range}set range(e){this._range=e,this._rangeCallback(this)}get ariaMessage(){const e=this.parent.getPreview(this)?.preview(this.range);return e?(0,d.kg)({key:"aria.oneReference.preview",comment:["Placeholders are: 0: filename, 1:line number, 2: column number, 3: preview snippet of source code"]},"{0} in {1} on line {2} at column {3}",e.value,(0,c.P8)(this.uri),this.range.startLineNumber,this.range.startColumn):(0,d.kg)("aria.oneReference","in {0} on line {1} at column {2}",(0,c.P8)(this.uri),this.range.startLineNumber,this.range.startColumn)}}class g{constructor(e){this._modelReference=e}dispose(){this._modelReference.dispose()}preview(e,t=8){const i=this._modelReference.object.textEditorModel;if(!i)return;const{startLineNumber:s,startColumn:n,endLineNumber:r,endColumn:o}=e,a=i.getWordUntilPosition({lineNumber:s,column:n-t}),c=new h.Q(s,a.startColumn,s,n),l=new h.Q(r,o,r,1073741824),d=i.getValueInRange(c).replace(/^\s+/,""),u=i.getValueInRange(e);return{value:d+u+i.getValueInRange(l).replace(/\s+$/,""),highlight:{start:d.length,end:d.length+u.length}}}}class p{constructor(e,t){this.parent=e,this.uri=t,this.children=[],this._previews=new a.fT}dispose(){(0,o.AS)(this._previews.values()),this._previews.clear()}getPreview(e){return this._previews.get(e.uri)}get ariaMessage(){const e=this.children.length;return 1===e?(0,d.kg)("aria.fileReferences.1","1 symbol in {0}, full path {1}",(0,c.P8)(this.uri),this.uri.fsPath):(0,d.kg)("aria.fileReferences.N","{0} symbols in {1}, full path {2}",e,(0,c.P8)(this.uri),this.uri.fsPath)}async resolve(e){if(0!==this._previews.size)return this;for(const i of this.children)if(!this._previews.has(i.uri))try{const t=await e.createModelReference(i.uri);this._previews.set(i.uri,new g(t))}catch(t){(0,s.dz)(t)}return this}}class m{constructor(e,t){this.groups=[],this.references=[],this._onDidChangeReferenceRange=new n.vl,this.onDidChangeReferenceRange=this._onDidChangeReferenceRange.event,this._links=e,this._title=t;const[i]=e;let s;e.sort(m._compareReferences);for(const n of e)if(s&&c.er.isEqual(s.uri,n.uri,!0)||(s=new p(this,n.uri),this.groups.push(s)),0===s.children.length||0!==m._compareReferences(n,s.children[s.children.length-1])){const e=new u(i===n,s,n,(e=>this._onDidChangeReferenceRange.fire(e)));this.references.push(e),s.children.push(e)}}dispose(){(0,o.AS)(this.groups),this._onDidChangeReferenceRange.dispose(),this.groups.length=0}clone(){return new m(this._links,this._title)}get title(){return this._title}get isEmpty(){return 0===this.groups.length}get ariaMessage(){return this.isEmpty?(0,d.kg)("aria.result.0","No results found"):1===this.references.length?(0,d.kg)("aria.result.1","Found 1 symbol in {0}",this.references[0].uri.fsPath):1===this.groups.length?(0,d.kg)("aria.result.n1","Found {0} symbols in {1}",this.references.length,this.groups[0].uri.fsPath):(0,d.kg)("aria.result.nm","Found {0} symbols in {1} files",this.references.length,this.groups.length)}nextOrPreviousReference(e,t){const{parent:i}=e;let s=i.children.indexOf(e);const n=i.children.length,r=i.parent.groups.length;return 1===r||t&&s+10?(s=t?(s+1)%n:(s+n-1)%n,i.children[s]):(s=i.parent.groups.indexOf(i),t?(s=(s+1)%r,i.parent.groups[s].children[0]):(s=(s+r-1)%r,i.parent.groups[s].children[i.parent.groups[s].children.length-1]))}nearestReference(e,t){const i=this.references.map(((i,s)=>({idx:s,prefixLen:l.Qp(i.uri.toString(),e.toString()),offsetDist:100*Math.abs(i.range.startLineNumber-t.lineNumber)+Math.abs(i.range.startColumn-t.column)}))).sort(((e,t)=>e.prefixLen>t.prefixLen?-1:e.prefixLent.offsetDist?1:0))[0];if(i)return this.references[i.idx]}referenceAt(e,t){for(const i of this.references)if(i.uri.toString()===e.toString()&&h.Q.containsPosition(i.range,t))return i}firstReference(){for(const e of this.references)if(e.isProviderFirst)return e;return this.references[0]}static _compareReferences(e,t){return c.er.compare(e.uri,t.uri)||h.Q.compareRangesUsingStarts(e.range,t.range)}}},79879:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"m3.003 4.702 4.22-2.025a1.8 1.8 0 0 1 1.554 0l4.22 2.025a.89.89 0 0 1 .503.8V6a8.55 8.55 0 0 1-3.941 7.201l-.986.631a1.06 1.06 0 0 1-1.146 0l-.986-.63A8.55 8.55 0 0 1 2.5 6v-.498c0-.341.196-.652.503-.8m3.57-3.377L2.354 3.35A2.39 2.39 0 0 0 1 5.502V6a10.05 10.05 0 0 0 4.632 8.465l.986.63a2.56 2.56 0 0 0 2.764 0l.986-.63A10.05 10.05 0 0 0 15 6v-.498c0-.918-.526-1.755-1.354-2.152l-4.22-2.025a3.3 3.3 0 0 0-2.852 0M9.5 7a1.5 1.5 0 0 1-.75 1.3v1.95a.75.75 0 0 1-1.5 0V8.3A1.5 1.5 0 1 1 9.5 7",clipRule:"evenodd"}))},79907:(e,t,i)=>{"use strict";var s=i(78209),n=i(11007),r=i(90766),o=i(18447),a=i(64383),c=i(5662),l=i(34326),h=i(31450),d=i(80301),u=i(36677),g=i(60002),p=i(16223),m=i(56942),f=i(13864),_=i(32848),v=i(36456),C=i(74320),E=i(54459),b=i(89403),S=i(26486),y=i(62083),w=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},R=function(e,t){return function(i,s){t(i,s,e)}};class L{constructor(){this.selector={language:"*"}}provideDocumentHighlights(e,t,i){const s=[],n=e.getWordAtPosition({lineNumber:t.lineNumber,column:t.column});if(!n)return Promise.resolve(s);if(e.isDisposed())return;return e.findMatches(n.word,!0,!1,!0,S.J3,!1).map((e=>({range:e.range,kind:y.Kb.Text})))}provideMultiDocumentHighlights(e,t,i,s){const n=new C.fT,r=e.getWordAtPosition({lineNumber:t.lineNumber,column:t.column});if(!r)return Promise.resolve(n);for(const o of[e,...i]){if(o.isDisposed())continue;const e=o.findMatches(r.word,!0,!1,!0,S.J3,!1).map((e=>({range:e.range,kind:y.Kb.Text})));e&&n.set(o.uri,e)}return n}}let T=class extends c.jG{constructor(e){super(),this._register(e.documentHighlightProvider.register("*",new L)),this._register(e.multiDocumentHighlightProvider.register("*",new L))}};T=w([R(0,m.ILanguageFeaturesService)],T);var x,k,A=i(72466),N=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},I=function(e,t){return function(i,s){t(i,s,e)}};const O=new _.N1("hasWordHighlights",!1);function D(e,t,i,s){const n=e.ordered(t);return(0,r.$1)(n.map((e=>()=>Promise.resolve(e.provideDocumentHighlights(t,i,s)).then(void 0,a.M_))),(e=>void 0!==e&&null!==e)).then((e=>{if(e){const i=new C.fT;return i.set(t.uri,e),i}return new C.fT}))}class M{constructor(e,t,i){this._model=e,this._selection=t,this._wordSeparators=i,this._wordRange=this._getCurrentWordRange(e,t),this._result=null}get result(){return this._result||(this._result=(0,r.SS)((e=>this._compute(this._model,this._selection,this._wordSeparators,e)))),this._result}_getCurrentWordRange(e,t){const i=e.getWordAtPosition(t.getPosition());return i?new u.Q(t.startLineNumber,i.startColumn,t.startLineNumber,i.endColumn):null}isValid(e,t,i){const s=t.startLineNumber,n=t.startColumn,r=t.endColumn,o=this._getCurrentWordRange(e,t);let a=Boolean(this._wordRange&&this._wordRange.equalsRange(o));for(let c=0,l=i.length;!a&&c=r&&(a=!0)}return a}cancel(){this.result.cancel()}}class P extends M{constructor(e,t,i,s){super(e,t,i),this._providers=s}_compute(e,t,i,s){return D(this._providers,e,t.getPosition(),s).then((e=>e||new C.fT))}}class F extends M{constructor(e,t,i,s,n){super(e,t,i),this._providers=s,this._otherModels=n}_compute(e,t,i,s){return function(e,t,i,s,n,o){const c=e.ordered(t);return(0,r.$1)(c.map((e=>()=>{const s=o.filter((e=>(0,p.vd)(e))).filter((t=>(0,E.f)(e.selector,t.uri,t.getLanguageId(),!0,void 0,void 0)>0));return Promise.resolve(e.provideMultiDocumentHighlights(t,i,s,n)).then(void 0,a.M_)})),(e=>void 0!==e&&null!==e))}(this._providers,e,t.getPosition(),0,s,this._otherModels).then((e=>e||new C.fT))}}(0,h.ke)("_executeDocumentHighlights",(async(e,t,i)=>{const s=e.get(m.ILanguageFeaturesService),n=await D(s.documentHighlightProvider,t,i,o.XO.None);return n?.get(t.uri)}));let U=class{static{x=this}static{this.storedDecorationIDs=new C.fT}static{this.query=null}constructor(e,t,i,s,n){this.toUnhook=new c.Cm,this.workerRequestTokenId=0,this.workerRequestCompleted=!1,this.workerRequestValue=new C.fT,this.lastCursorPositionChangeTime=0,this.renderDecorationsTimer=-1,this.runDelayer=this.toUnhook.add(new r.ve(50)),this.editor=e,this.providers=t,this.multiDocumentProviders=i,this.codeEditorService=n,this._hasWordHighlights=O.bindTo(s),this._ignorePositionChangeEvent=!1,this.occurrencesHighlight=this.editor.getOption(81),this.model=this.editor.getModel(),this.toUnhook.add(e.onDidChangeCursorPosition((e=>{this._ignorePositionChangeEvent||"off"!==this.occurrencesHighlight&&this.runDelayer.trigger((()=>{this._onPositionChanged(e)}))}))),this.toUnhook.add(e.onDidFocusEditorText((e=>{"off"!==this.occurrencesHighlight&&(this.workerRequest||this.runDelayer.trigger((()=>{this._run()})))}))),this.toUnhook.add(e.onDidChangeModelContent((e=>{(0,v.v$)(this.model.uri,"output")||this._stopAll()}))),this.toUnhook.add(e.onDidChangeModel((e=>{!e.newModelUrl&&e.oldModelUrl?this._stopSingular():x.query&&this._run()}))),this.toUnhook.add(e.onDidChangeConfiguration((e=>{const t=this.editor.getOption(81);if(this.occurrencesHighlight!==t)switch(this.occurrencesHighlight=t,t){case"off":this._stopAll();break;case"singleFile":this._stopAll(x.query?.modelInfo?.model);break;case"multiFile":x.query&&this._run(!0);break;default:console.warn("Unknown occurrencesHighlight setting value:",t)}}))),this.decorations=this.editor.createDecorationsCollection(),this.workerRequestTokenId=0,this.workerRequest=null,this.workerRequestCompleted=!1,this.lastCursorPositionChangeTime=0,this.renderDecorationsTimer=-1,x.query&&this._run()}hasDecorations(){return this.decorations.length>0}restore(){"off"!==this.occurrencesHighlight&&(this.runDelayer.cancel(),this._run())}_getSortedHighlights(){return this.decorations.getRanges().sort(u.Q.compareRangesUsingStarts)}moveNext(){const e=this._getSortedHighlights(),t=e.findIndex((e=>e.containsPosition(this.editor.getPosition()))),i=(t+1)%e.length,s=e[i];try{this._ignorePositionChangeEvent=!0,this.editor.setPosition(s.getStartPosition()),this.editor.revealRangeInCenterIfOutsideViewport(s);const t=this._getWord();if(t){const r=this.editor.getModel().getLineContent(s.startLineNumber);(0,n.xE)(`${r}, ${i+1} of ${e.length} for '${t.word}'`)}}finally{this._ignorePositionChangeEvent=!1}}moveBack(){const e=this._getSortedHighlights(),t=e.findIndex((e=>e.containsPosition(this.editor.getPosition()))),i=(t-1+e.length)%e.length,s=e[i];try{this._ignorePositionChangeEvent=!0,this.editor.setPosition(s.getStartPosition()),this.editor.revealRangeInCenterIfOutsideViewport(s);const t=this._getWord();if(t){const r=this.editor.getModel().getLineContent(s.startLineNumber);(0,n.xE)(`${r}, ${i+1} of ${e.length} for '${t.word}'`)}}finally{this._ignorePositionChangeEvent=!1}}_removeSingleDecorations(){if(!this.editor.hasModel())return;const e=x.storedDecorationIDs.get(this.editor.getModel().uri);e&&(this.editor.removeDecorations(e),x.storedDecorationIDs.delete(this.editor.getModel().uri),this.decorations.length>0&&(this.decorations.clear(),this._hasWordHighlights.set(!1)))}_removeAllDecorations(e){const t=this.codeEditorService.listCodeEditors(),i=[];for(const s of t){if(!s.hasModel()||(0,b.n4)(s.getModel().uri,e?.uri))continue;const t=x.storedDecorationIDs.get(s.getModel().uri);if(!t)continue;s.removeDecorations(t),i.push(s.getModel().uri);const n=H.get(s);n?.wordHighlighter&&(n.wordHighlighter.decorations.length>0&&(n.wordHighlighter.decorations.clear(),n.wordHighlighter.workerRequest=null,n.wordHighlighter._hasWordHighlights.set(!1)))}for(const s of i)x.storedDecorationIDs.delete(s)}_stopSingular(){this._removeSingleDecorations(),this.editor.hasTextFocus()&&(this.editor.getModel()?.uri.scheme!==v.ny.vscodeNotebookCell&&x.query?.modelInfo?.model.uri.scheme!==v.ny.vscodeNotebookCell?(x.query=null,this._run()):x.query?.modelInfo&&(x.query.modelInfo=null)),-1!==this.renderDecorationsTimer&&(clearTimeout(this.renderDecorationsTimer),this.renderDecorationsTimer=-1),null!==this.workerRequest&&(this.workerRequest.cancel(),this.workerRequest=null),this.workerRequestCompleted||(this.workerRequestTokenId++,this.workerRequestCompleted=!0)}_stopAll(e){this._removeAllDecorations(e),-1!==this.renderDecorationsTimer&&(clearTimeout(this.renderDecorationsTimer),this.renderDecorationsTimer=-1),null!==this.workerRequest&&(this.workerRequest.cancel(),this.workerRequest=null),this.workerRequestCompleted||(this.workerRequestTokenId++,this.workerRequestCompleted=!0)}_onPositionChanged(e){"off"!==this.occurrencesHighlight&&(3===e.reason||this.editor.getModel()?.uri.scheme===v.ny.vscodeNotebookCell)?this._run():this._stopAll()}_getWord(){const e=this.editor.getSelection(),t=e.startLineNumber,i=e.startColumn;return this.model.isDisposed()?null:this.model.getWordAtPosition({lineNumber:t,column:i})}getOtherModelsToHighlight(e){if(!e)return[];if(e.uri.scheme===v.ny.vscodeNotebookCell){const t=[],i=this.codeEditorService.listCodeEditors();for(const s of i){const i=s.getModel();i&&i!==e&&i.uri.scheme===v.ny.vscodeNotebookCell&&t.push(i)}return t}const t=[],i=this.codeEditorService.listCodeEditors();for(const s of i){if(!(0,l.Np)(s))continue;const i=s.getModel();i&&(e===i.modified&&t.push(i.modified))}if(t.length)return t;if("singleFile"===this.occurrencesHighlight)return[];for(const s of i){const i=s.getModel();i&&i!==e&&t.push(i)}return t}_run(e){let t;if(this.editor.hasTextFocus()){const e=this.editor.getSelection();if(!e||e.startLineNumber!==e.endLineNumber)return x.query=null,void this._stopAll();const i=e.startColumn,s=e.endColumn,n=this._getWord();if(!n||n.startColumn>i||n.endColumn{t===this.workerRequestTokenId&&(this.workerRequestCompleted=!0,this.workerRequestValue=e||[],this._beginRenderDecorations())}),a.dz)}}computeWithModel(e,t,i,s){return s.length?function(e,t,i,s,n,r){return new F(t,i,n,e,r)}(this.multiDocumentProviders,e,t,0,this.editor.getOption(132),s):function(e,t,i,s,n){return new P(t,i,n,e)}(this.providers,e,t,0,this.editor.getOption(132))}_beginRenderDecorations(){const e=(new Date).getTime(),t=this.lastCursorPositionChangeTime+250;e>=t?(this.renderDecorationsTimer=-1,this.renderDecorations()):this.renderDecorationsTimer=setTimeout((()=>{this.renderDecorations()}),t-e)}renderDecorations(){this.renderDecorationsTimer=-1;const e=this.codeEditorService.listCodeEditors();for(const t of e){const e=H.get(t);if(!e)continue;const i=[],s=t.getModel()?.uri;if(s&&this.workerRequestValue.has(s)){const n=x.storedDecorationIDs.get(s),r=this.workerRequestValue.get(s);if(r)for(const e of r)e.range&&i.push({range:e.range,options:(0,f.P)(e.kind)});let o=[];t.changeDecorations((e=>{o=e.deltaDecorations(n??[],i)})),x.storedDecorationIDs=x.storedDecorationIDs.set(s,o),i.length>0&&(e.wordHighlighter?.decorations.set(i),e.wordHighlighter?._hasWordHighlights.set(!0))}}}dispose(){this._stopSingular(),this.toUnhook.dispose()}};U=x=N([I(4,d.T)],U);let H=class extends c.jG{static{k=this}static{this.ID="editor.contrib.wordHighlighter"}static get(e){return e.getContribution(k.ID)}constructor(e,t,i,s){super(),this._wordHighlighter=null;const n=()=>{e.hasModel()&&!e.getModel().isTooLargeForTokenization()&&(this._wordHighlighter=new U(e,i.documentHighlightProvider,i.multiDocumentHighlightProvider,t,s))};this._register(e.onDidChangeModel((e=>{this._wordHighlighter&&(this._wordHighlighter.dispose(),this._wordHighlighter=null),n()}))),n()}get wordHighlighter(){return this._wordHighlighter}saveViewState(){return!(!this._wordHighlighter||!this._wordHighlighter.hasDecorations())}moveNext(){this._wordHighlighter?.moveNext()}moveBack(){this._wordHighlighter?.moveBack()}restoreViewState(e){this._wordHighlighter&&e&&this._wordHighlighter.restore()}dispose(){this._wordHighlighter&&(this._wordHighlighter.dispose(),this._wordHighlighter=null),super.dispose()}};H=k=N([I(1,_.fN),I(2,m.ILanguageFeaturesService),I(3,d.T)],H);class B extends h.ks{constructor(e,t){super(t),this._isNext=e}run(e,t){const i=H.get(t);i&&(this._isNext?i.moveNext():i.moveBack())}}class W extends h.ks{constructor(){super({id:"editor.action.wordHighlight.trigger",label:s.kg("wordHighlight.trigger.label","Trigger Symbol Highlight"),alias:"Trigger Symbol Highlight",precondition:void 0,kbOpts:{kbExpr:g.R.editorTextFocus,primary:0,weight:100}})}run(e,t,i){const s=H.get(t);s&&s.restoreViewState(!0)}}(0,h.HW)(H.ID,H,0),(0,h.Fl)(class extends B{constructor(){super(!0,{id:"editor.action.wordHighlight.next",label:s.kg("wordHighlight.next.label","Go to Next Symbol Highlight"),alias:"Go to Next Symbol Highlight",precondition:O,kbOpts:{kbExpr:g.R.editorTextFocus,primary:65,weight:100}})}}),(0,h.Fl)(class extends B{constructor(){super(!1,{id:"editor.action.wordHighlight.prev",label:s.kg("wordHighlight.previous.label","Go to Previous Symbol Highlight"),alias:"Go to Previous Symbol Highlight",precondition:O,kbOpts:{kbExpr:g.R.editorTextFocus,primary:1089,weight:100}})}}),(0,h.Fl)(W),(0,A.x)(T)},79928:e=>{e.exports=function(){function e(e){return e.$value}return e.isScalar=!0,e}},80200:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"csp",extensions:[".csp"],aliases:["CSP","csp"],loader:()=>i.e(55454).then(i.bind(i,55454))})},80301:(e,t,i)=>{"use strict";i.d(t,{T:()=>s});const s=(0,i(63591).u1)("codeEditorService")},80409:(e,t,i)=>{"use strict";var s=i(31450),n=i(57039),r=i(31308),o=i(49154),a=i(60002),c=i(78244),l=i(62051),h=i(8597),d=i(5662);var u=i(11007),g=i(90766),p=i(18447),m=i(87958),f=i(13850),_=i(631),v=i(36999),C=i(38844),E=i(83069),b=i(32500),S=i(56942),y=i(80789),w=i(41234),R=i(91508),L=i(73157),T=i(87908),x=i(36677),k=i(99020),A=i(10154),N=i(16223),I=i(87469),O=i(25521),D=i(35600),M=i(92674),P=i(73401),F=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},U=function(e,t){return function(i,s){t(i,s,e)}};const H="ghost-text";let B=class extends d.jG{constructor(e,t,i){super(),this.editor=e,this.model=t,this.languageService=i,this.isDisposed=(0,r.FY)(this,!1),this.currentTextModel=(0,r.y0)(this,this.editor.onDidChangeModel,(()=>this.editor.getModel())),this.uiState=(0,r.un)(this,(e=>{if(this.isDisposed.read(e))return;const t=this.currentTextModel.read(e);if(t!==this.model.targetTextModel.read(e))return;const i=this.model.ghostText.read(e);if(!i)return;const s=i instanceof M.Vs?i.columnRange:void 0,n=[],r=[];function o(e,t){if(r.length>0){const i=r[r.length-1];t&&i.decorations.push(new O.d(i.content.length+1,i.content.length+1+e[0].length,t,0)),i.content+=e[0],e=e.slice(1)}for(const i of e)r.push({content:i,decorations:t?[new O.d(1,i.length+1,t,0)]:[]})}const a=t.getLineContent(i.lineNumber);let c,l=0;for(const d of i.parts){let e=d.lines;void 0===c?(n.push({column:d.column,text:e[0],preview:d.preview}),e=e.slice(1)):o([a.substring(l,d.column-1)],void 0),e.length>0&&(o(e,H),void 0===c&&d.column<=a.length&&(c=d.column)),l=d.column-1}void 0!==c&&o([a.substring(l)],void 0);const h=void 0!==c?new P.GM(c,a.length+1):void 0;return{replacedRange:s,inlineTexts:n,additionalLines:r,hiddenRange:h,lineNumber:i.lineNumber,additionalReservedLineCount:this.model.minReservedLineCount.read(e),targetTextModel:t}})),this.decorations=(0,r.un)(this,(e=>{const t=this.uiState.read(e);if(!t)return[];const i=[];t.replacedRange&&i.push({range:t.replacedRange.toRange(t.lineNumber),options:{inlineClassName:"inline-completion-text-to-replace",description:"GhostTextReplacement"}}),t.hiddenRange&&i.push({range:t.hiddenRange.toRange(t.lineNumber),options:{inlineClassName:"ghost-text-hidden",description:"ghost-text-hidden"}});for(const s of t.inlineTexts)i.push({range:x.Q.fromPositions(new E.y(t.lineNumber,s.column)),options:{description:H,after:{content:s.text,inlineClassName:s.preview?"ghost-text-decoration-preview":"ghost-text-decoration",cursorStops:N.VW.Left},showIfCollapsed:!0}});return i})),this.additionalLinesWidget=this._register(new W(this.editor,this.languageService.languageIdCodec,(0,r.un)((e=>{const t=this.uiState.read(e);return t?{lineNumber:t.lineNumber,additionalLines:t.additionalLines,minReservedLineCount:t.additionalReservedLineCount,targetTextModel:t.targetTextModel}:void 0})))),this._register((0,d.s)((()=>{this.isDisposed.set(!0,void 0)}))),this._register((0,P.pY)(this.editor,this.decorations))}ownsViewZone(e){return this.additionalLinesWidget.viewZoneId===e}};B=F([U(2,A.L)],B);class W extends d.jG{get viewZoneId(){return this._viewZoneId}constructor(e,t,i){super(),this.editor=e,this.languageIdCodec=t,this.lines=i,this._viewZoneId=void 0,this.editorOptionsChanged=(0,r.yQ)("editorOptionChanged",w.Jh.filter(this.editor.onDidChangeConfiguration,(e=>e.hasChanged(33)||e.hasChanged(118)||e.hasChanged(100)||e.hasChanged(95)||e.hasChanged(51)||e.hasChanged(50)||e.hasChanged(67)))),this._register((0,r.fm)((e=>{const t=this.lines.read(e);this.editorOptionsChanged.read(e),t?this.updateLines(t.lineNumber,t.additionalLines,t.minReservedLineCount):this.clear()})))}dispose(){super.dispose(),this.clear()}clear(){this.editor.changeViewZones((e=>{this._viewZoneId&&(e.removeZone(this._viewZoneId),this._viewZoneId=void 0)}))}updateLines(e,t,i){const s=this.editor.getModel();if(!s)return;const{tabSize:n}=s.getOptions();this.editor.changeViewZones((s=>{this._viewZoneId&&(s.removeZone(this._viewZoneId),this._viewZoneId=void 0);const r=Math.max(t.length,i);if(r>0){const i=document.createElement("div");!function(e,t,i,s,n){const r=s.get(33),o=s.get(118),a="none",c=s.get(95),l=s.get(51),h=s.get(50),d=s.get(67),u=new k.fe(1e4);u.appendString('
    ');for(let m=0,f=i.length;m');const g=R.aC(s),p=R.E_(s),f=I.f.createEmpty(s,n);(0,D.UW)(new D.zL(h.isMonospace&&!r,h.canUseHalfwidthRightwardsArrow,s,!1,g,p,0,f,e.decorations,t,0,h.spaceWidth,h.middotWidth,h.wsmiddotWidth,o,a,c,l!==T.Bc.OFF,null),u),u.appendString("
    ")}u.appendString(""),(0,L.M)(e,h);const g=u.build(),p=V?V.createHTML(g):g;e.innerHTML=p}(i,n,t,this.editor.getOptions(),this.languageIdCodec),this._viewZoneId=s.addZone({afterLineNumber:e,heightInLines:r,domNode:i,afterColumnAffinity:1})}}))}}const V=(0,y.H)("editorGhostText",{createHTML:e=>e});var z=i(64317),G=i(25890),j=i(46041),K=i(51241),Y=i(64383),q=i(7085),$=i(75326),Q=i(75295),X=i(50973),Z=i(62083),J=i(17469),ee=i(26690),te=i(20940),ie=i(83993);function se(e,t,i){const s=i?e.range.intersectRanges(i):e.range;if(!s)return e;const n=t.getValueInRange(s,1),r=(0,R.Qp)(n,e.text),o=X.W.ofText(n.substring(0,r)).addToPosition(e.range.getStartPosition()),a=e.text.substring(r),c=x.Q.fromPositions(o,e.range.getEndPosition());return new Q.WR(c,a)}function ne(e,t){return e.text.startsWith(t.text)&&(i=e.range,(s=t.range).getStartPosition().equals(i.getStartPosition())&&s.getEndPosition().isBeforeOrEqual(i.getEndPosition()));var i,s}function re(e,t,i,s,n=0){let r=se(e,t);if(r.range.endLineNumber!==r.range.startLineNumber)return;const o=t.getLineContent(r.range.startLineNumber),a=(0,R.UU)(o).length;if(r.range.startColumn-1<=a){const e=(0,R.UU)(r.text).length,t=o.substring(r.range.startColumn-1,a),[i,s]=[r.range.getStartPosition(),r.range.getEndPosition()],n=i.column+t.length<=s.column?i.delta(0,t.length):s,c=x.Q.fromPositions(n,s),l=r.text.startsWith(t)?r.text.substring(t.length):r.text.substring(e);r=new Q.WR(c,l)}const c=t.getValueInRange(r.range),l=function(e,t){if(oe?.originalValue===e&&oe?.newValue===t)return oe?.changes;{let i=ce(e,t,!0);if(i){const s=ae(i);if(s>0){const n=ce(e,t,!1);n&&ae(n)0===e.originalLength));if(e.length>1||1===e.length&&e[0].originalStart!==c.length)return}const u=r.text.length-n;for(const g of l){const e=r.range.startColumn+g.originalStart+g.originalLength;if("subwordSmart"===i&&s&&s.lineNumber===r.range.startLineNumber&&e0)return;if(0===g.modifiedLength)continue;const t=g.modifiedStart+g.modifiedLength,n=Math.max(g.modifiedStart,Math.min(t,u)),o=r.text.substring(g.modifiedStart,n),a=r.text.substring(n,Math.max(g.modifiedStart,t));o.length>0&&d.push(new M.yP(e,o,!1)),a.length>0&&d.push(new M.yP(e,a,!0))}return new M.xD(h,d)}let oe;function ae(e){let t=0;for(const i of e)t+=i.originalLength;return t}function ce(e,t,i){if(e.length>5e3||t.length>5e3)return;function s(e){let t=0;for(let i=0,s=e.length;it&&(t=s)}return t}const n=Math.max(s(e),s(t));function r(e){if(e<0)throw new Error("unexpected");return n+e+1}function o(e){let t=0,s=0;const n=new Int32Array(e.length);for(let o=0,a=e.length;oa},{getElements:()=>c}).ComputeDiff(!1).changes}var le=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},he=function(e,t){return function(i,s){t(i,s,e)}};let de=class extends d.jG{constructor(e,t,i,s,n){super(),this.textModel=e,this.versionId=t,this._debounceValue=i,this.languageFeaturesService=s,this.languageConfigurationService=n,this._updateOperation=this._register(new d.HE),this.inlineCompletions=(0,r.X2)("inlineCompletions",void 0),this.suggestWidgetInlineCompletions=(0,r.X2)("suggestWidgetInlineCompletions",void 0),this._register(this.textModel.onDidChangeContent((()=>{this._updateOperation.clear()})))}fetch(e,t,i){const s=new ue(e,t,this.textModel.getVersionId()),n=t.selectedSuggestionInfo?this.suggestWidgetInlineCompletions:this.inlineCompletions;if(this._updateOperation.value?.request.satisfies(s))return this._updateOperation.value.promise;if(n.get()?.request.satisfies(s))return Promise.resolve(!0);const o=!!this._updateOperation.value;this._updateOperation.clear();const a=new p.Qi,c=(async()=>{var c,l;if((o||t.triggerKind===Z.qw.Automatic)&&await(c=this._debounceValue.get(this.textModel),l=a.token,new Promise((e=>{let t;const i=setTimeout((()=>{t&&t.dispose(),e()}),c);l&&(t=l.onCancellationRequested((()=>{clearTimeout(i),t&&t.dispose(),e()})))}))),a.token.isCancellationRequested||this._store.isDisposed||this.textModel.getVersionId()!==s.versionId)return!1;const h=new Date,d=await(0,te.Yk)(this.languageFeaturesService.inlineCompletionsProvider,e,this.textModel,t,a.token,this.languageConfigurationService);if(a.token.isCancellationRequested||this._store.isDisposed||this.textModel.getVersionId()!==s.versionId)return!1;const u=new Date;this._debounceValue.update(this.textModel,u.getTime()-h.getTime());const g=new pe(d,s,this.textModel,this.versionId);if(i){const t=i.toInlineCompletion(void 0);i.canBeReused(this.textModel,e)&&!d.has(t)&&g.prepend(i.inlineCompletion,t.range,!0)}return this._updateOperation.clear(),(0,r.Rn)((e=>{n.set(g,e)})),!0})(),l=new ge(s,a,c);return this._updateOperation.value=l,c}clear(e){this._updateOperation.clear(),this.inlineCompletions.set(void 0,e),this.suggestWidgetInlineCompletions.set(void 0,e)}clearSuggestWidgetInlineCompletions(e){this._updateOperation.value?.request.context.selectedSuggestionInfo&&this._updateOperation.clear(),this.suggestWidgetInlineCompletions.set(void 0,e)}cancelUpdate(){this._updateOperation.clear()}};de=le([he(3,S.ILanguageFeaturesService),he(4,J.JZ)],de);class ue{constructor(e,t,i){this.position=e,this.context=t,this.versionId=i}satisfies(e){return this.position.equals(e.position)&&(0,K.KC)(this.context.selectedSuggestionInfo,e.context.selectedSuggestionInfo,(0,K.r)())&&(e.context.triggerKind===Z.qw.Automatic||this.context.triggerKind===Z.qw.Explicit)&&this.versionId===e.versionId}}class ge{constructor(e,t,i){this.request=e,this.cancellationTokenSource=t,this.promise=i}dispose(){this.cancellationTokenSource.cancel()}}class pe{get inlineCompletions(){return this._inlineCompletions}constructor(e,t,i,s){this.inlineCompletionProviderResult=e,this.request=t,this._textModel=i,this._versionId=s,this._refCount=1,this._prependedInlineCompletionItems=[];const n=i.deltaDecorations([],e.completions.map((e=>({range:e.range,options:{description:"inline-completion-tracking-range"}}))));this._inlineCompletions=e.completions.map(((e,t)=>new me(e,n[t],this._textModel,this._versionId)))}clone(){return this._refCount++,this}dispose(){if(this._refCount--,0===this._refCount){setTimeout((()=>{this._textModel.isDisposed()||this._textModel.deltaDecorations(this._inlineCompletions.map((e=>e.decorationId)),[])}),0),this.inlineCompletionProviderResult.dispose();for(const e of this._prependedInlineCompletionItems)e.source.removeRef()}}prepend(e,t,i){i&&e.source.addRef();const s=this._textModel.deltaDecorations([],[{range:t,options:{description:"inline-completion-tracking-range"}}])[0];this._inlineCompletions.unshift(new me(e,s,this._textModel,this._versionId)),this._prependedInlineCompletionItems.push(e)}}class me{get forwardStable(){return this.inlineCompletion.source.inlineCompletions.enableForwardStability??!1}constructor(e,t,i,s){this.inlineCompletion=e,this.decorationId=t,this._textModel=i,this._modelVersion=s,this.semanticId=JSON.stringify([this.inlineCompletion.filterText,this.inlineCompletion.insertText,this.inlineCompletion.range.getStartPosition().toString()]),this._updatedRange=(0,r.C)({owner:this,equalsFn:x.Q.equalsRange},(e=>(this._modelVersion.read(e),this._textModel.getDecorationRange(this.decorationId))))}toInlineCompletion(e){return this.inlineCompletion.withRange(this._updatedRange.read(e)??fe)}toSingleTextEdit(e){return new Q.WR(this._updatedRange.read(e)??fe,this.inlineCompletion.insertText)}isVisible(e,t,i){const s=se(this._toFilterTextReplacement(i),e),n=this._updatedRange.read(i);if(!n||!this.inlineCompletion.range.getStartPosition().equals(n.getStartPosition())||t.lineNumber!==s.range.startLineNumber)return!1;const r=e.getValueInRange(s.range,1),o=s.text,a=Math.max(0,t.column-s.range.startColumn);let c=o.substring(0,a),l=o.substring(a),h=r.substring(0,a),d=r.substring(a);const u=e.getLineIndentColumn(s.range.startLineNumber);return s.range.startColumn<=u&&(h=h.trimStart(),0===h.length&&(d=d.trimStart()),c=c.trimStart(),0===c.length&&(l=l.trimStart())),c.startsWith(h)&&!!(0,ee.dE)(d,l)}canBeReused(e,t){const i=this._updatedRange.read(void 0);return!!i&&i.containsPosition(t)&&this.isVisible(e,t,void 0)&&X.W.ofRange(i).isGreaterThanOrEqualTo(X.W.ofRange(this.inlineCompletion.range))}_toFilterTextReplacement(e){return new Q.WR(this._updatedRange.read(e)??fe,this.inlineCompletion.filterText)}}const fe=new x.Q(1,1,1,1);var _e=i(30936),ve=i(50091),Ce=i(63591),Ee=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},be=function(e,t){return function(i,s){t(i,s,e)}};let Se=class extends d.jG{get isAcceptingPartially(){return this._isAcceptingPartially}constructor(e,t,i,s,n,o,a,c,l,h,d,u){let g;super(),this.textModel=e,this.selectedSuggestItem=t,this._textModelVersionId=i,this._positions=s,this._debounceValue=n,this._suggestPreviewEnabled=o,this._suggestPreviewMode=a,this._inlineSuggestMode=c,this._enabled=l,this._instantiationService=h,this._commandService=d,this._languageConfigurationService=u,this._source=this._register(this._instantiationService.createInstance(de,this.textModel,this._textModelVersionId,this._debounceValue)),this._isActive=(0,r.FY)(this,!1),this._forceUpdateExplicitlySignal=(0,r.Yd)(this),this._selectedInlineCompletionId=(0,r.FY)(this,void 0),this._primaryPosition=(0,r.un)(this,(e=>this._positions.read(e)[0]??new E.y(1,1))),this._isAcceptingPartially=!1,this._preserveCurrentCompletionReasons=new Set([ye.Redo,ye.Undo,ye.AcceptWord]),this._fetchInlineCompletionsPromise=(0,r.nb)({owner:this,createEmptyChangeSummary:()=>({preserveCurrentCompletion:!1,inlineCompletionTriggerKind:Z.qw.Automatic}),handleChange:(e,t)=>(e.didChange(this._textModelVersionId)&&this._preserveCurrentCompletionReasons.has(this._getReason(e.change))?t.preserveCurrentCompletion=!0:e.didChange(this._forceUpdateExplicitlySignal)&&(t.inlineCompletionTriggerKind=Z.qw.Explicit),!0)},((e,t)=>{this._forceUpdateExplicitlySignal.read(e);if(!(this._enabled.read(e)&&this.selectedSuggestItem.read(e)||this._isActive.read(e)))return void this._source.cancelUpdate();this._textModelVersionId.read(e);const i=this._source.suggestWidgetInlineCompletions.get(),s=this.selectedSuggestItem.read(e);if(i&&!s){const e=this._source.inlineCompletions.get();(0,r.Rn)((t=>{(!e||i.request.versionId>e.request.versionId)&&this._source.inlineCompletions.set(i.clone(),t),this._source.clearSuggestWidgetInlineCompletions(t)}))}const n=this._primaryPosition.read(e),o={triggerKind:t.inlineCompletionTriggerKind,selectedSuggestionInfo:s?.toSelectedSuggestionInfo()},a=this.selectedInlineCompletion.get(),c=t.preserveCurrentCompletion||a?.forwardStable?a:void 0;return this._source.fetch(n,o,c)})),this._filteredInlineCompletionItems=(0,r.C)({owner:this,equalsFn:(0,K.S3)()},(e=>{const t=this._source.inlineCompletions.read(e);if(!t)return[];const i=this._primaryPosition.read(e),s=t.inlineCompletions.filter((t=>t.isVisible(this.textModel,i,e)));return s})),this.selectedInlineCompletionIndex=(0,r.un)(this,(e=>{const t=this._selectedInlineCompletionId.read(e),i=this._filteredInlineCompletionItems.read(e),s=void 0===this._selectedInlineCompletionId?-1:i.findIndex((e=>e.semanticId===t));return-1===s?(this._selectedInlineCompletionId.set(void 0,void 0),0):s})),this.selectedInlineCompletion=(0,r.un)(this,(e=>this._filteredInlineCompletionItems.read(e)[this.selectedInlineCompletionIndex.read(e)])),this.activeCommands=(0,r.C)({owner:this,equalsFn:(0,K.S3)()},(e=>this.selectedInlineCompletion.read(e)?.inlineCompletion.source.inlineCompletions.commands??[])),this.lastTriggerKind=this._source.inlineCompletions.map(this,(e=>e?.request.context.triggerKind)),this.inlineCompletionsCount=(0,r.un)(this,(e=>this.lastTriggerKind.read(e)===Z.qw.Explicit?this._filteredInlineCompletionItems.read(e).length:void 0)),this.state=(0,r.C)({owner:this,equalsFn:(e,t)=>e&&t?(0,M.AL)(e.ghostTexts,t.ghostTexts)&&e.inlineCompletion===t.inlineCompletion&&e.suggestItem===t.suggestItem:e===t},(e=>{const t=this.textModel,i=this.selectedSuggestItem.read(e);if(i){const s=se(i.toSingleTextEdit(),t),n=this._computeAugmentation(s,e);if(!this._suggestPreviewEnabled.read(e)&&!n)return;const r=n?.edit??s,o=n?n.edit.text.length-s.text.length:0,a=this._suggestPreviewMode.read(e),c=this._positions.read(e),l=[r,...we(this.textModel,c,r)],h=l.map(((e,i)=>re(e,t,a,c[i],o))).filter(_.O9);return{edits:l,primaryGhostText:h[0]??new M.xD(r.range.endLineNumber,[]),ghostTexts:h,inlineCompletion:n?.completion,suggestItem:i}}{if(!this._isActive.read(e))return;const i=this.selectedInlineCompletion.read(e);if(!i)return;const s=i.toSingleTextEdit(e),n=this._inlineSuggestMode.read(e),r=this._positions.read(e),o=[s,...we(this.textModel,r,s)],a=o.map(((e,i)=>re(e,t,n,r[i],0))).filter(_.O9);if(!a[0])return;return{edits:o,primaryGhostText:a[0],ghostTexts:a,inlineCompletion:i,suggestItem:void 0}}})),this.ghostTexts=(0,r.C)({owner:this,equalsFn:M.AL},(e=>{const t=this.state.read(e);if(t)return t.ghostTexts})),this.primaryGhostText=(0,r.C)({owner:this,equalsFn:M.x9},(e=>{const t=this.state.read(e);if(t)return t?.primaryGhostText})),this._register((0,r.OI)(this._fetchInlineCompletionsPromise)),this._register((0,r.fm)((e=>{const t=this.state.read(e),i=t?.inlineCompletion;if(i?.semanticId!==g?.semanticId&&(g=i,i)){const e=i.inlineCompletion,t=e.source;t.provider.handleItemDidShow?.(t.inlineCompletions,e.sourceInlineCompletion,e.insertText)}})))}_getReason(e){return e?.isUndoing?ye.Undo:e?.isRedoing?ye.Redo:this.isAcceptingPartially?ye.AcceptWord:ye.Other}async trigger(e){this._isActive.set(!0,e),await this._fetchInlineCompletionsPromise.get()}async triggerExplicitly(e){(0,r.PO)(e,(e=>{this._isActive.set(!0,e),this._forceUpdateExplicitlySignal.trigger(e)})),await this._fetchInlineCompletionsPromise.get()}stop(e){(0,r.PO)(e,(e=>{this._isActive.set(!1,e),this._source.clear(e)}))}_computeAugmentation(e,t){const i=this.textModel,s=this._source.suggestWidgetInlineCompletions.read(t),n=s?s.inlineCompletions:[this.selectedInlineCompletion.read(t)].filter(_.O9);return(0,j.oH)(n,(s=>{let n=s.toSingleTextEdit(t);return n=se(n,i,x.Q.fromPositions(n.range.getStartPosition(),e.range.getEndPosition())),ne(n,e)?{completion:s,edit:n}:void 0}))}async _deltaSelectedInlineCompletionIndex(e){await this.triggerExplicitly();const t=this._filteredInlineCompletionItems.get()||[];if(t.length>0){const i=(this.selectedInlineCompletionIndex.get()+e+t.length)%t.length;this._selectedInlineCompletionId.set(t[i].semanticId,void 0)}else this._selectedInlineCompletionId.set(void 0,void 0)}async next(){await this._deltaSelectedInlineCompletionIndex(1)}async previous(){await this._deltaSelectedInlineCompletionIndex(-1)}async accept(e){if(e.getModel()!==this.textModel)throw new Y.D7;const t=this.state.get();if(!t||t.primaryGhostText.isEmpty()||!t.inlineCompletion)return;const i=t.inlineCompletion.toInlineCompletion(void 0);if(i.command&&i.source.addRef(),e.pushUndoStop(),i.snippetInfo)e.executeEdits("inlineSuggestion.accept",[q.k.replace(i.range,""),...i.additionalTextEdits]),e.setPosition(i.snippetInfo.range.getStartPosition(),"inlineCompletionAccept"),_e.O.get(e)?.insert(i.snippetInfo.snippet,{undoStopBefore:!1});else{const s=t.edits,n=Re(s).map((e=>$.L.fromPositions(e)));e.executeEdits("inlineSuggestion.accept",[...s.map((e=>q.k.replace(e.range,e.text))),...i.additionalTextEdits]),e.setSelections(n,"inlineCompletionAccept")}this.stop(),i.command&&(await this._commandService.executeCommand(i.command.id,...i.command.arguments||[]).then(void 0,Y.M_),i.source.removeRef())}async acceptNextWord(e){await this._acceptNext(e,((e,t)=>{const i=this.textModel.getLanguageIdAtPosition(e.lineNumber,e.column),s=this._languageConfigurationService.getLanguageConfiguration(i),n=new RegExp(s.wordDefinition.source,s.wordDefinition.flags.replace("g","")),r=t.match(n);let o=0;o=r&&void 0!==r.index?0===r.index?r[0].length:r.index:t.length;const a=/\s+/g.exec(t);return a&&void 0!==a.index&&a.index+a[0].length{const i=t.match(/\n/);return i&&void 0!==i.index?i.index+1:t.length}),1)}async _acceptNext(e,t,i){if(e.getModel()!==this.textModel)throw new Y.D7;const s=this.state.get();if(!s||s.primaryGhostText.isEmpty()||!s.inlineCompletion)return;const n=s.primaryGhostText,r=s.inlineCompletion.toInlineCompletion(void 0);if(r.snippetInfo||r.filterText!==r.insertText)return void await this.accept(e);const o=n.parts[0],a=new E.y(n.lineNumber,o.column),c=o.text,l=t(a,c);if(l===c.length&&1===n.parts.length)return void this.accept(e);const h=c.substring(0,l),d=this._positions.get(),u=d[0];r.source.addRef();try{this._isAcceptingPartially=!0;try{e.pushUndoStop();const t=x.Q.fromPositions(u,a),i=e.getModel().getValueInRange(t)+h,s=new Q.WR(t,i),n=[s,...we(this.textModel,d,s)],r=Re(n).map((e=>$.L.fromPositions(e)));e.executeEdits("inlineSuggestion.accept",n.map((e=>q.k.replace(e.range,e.text)))),e.setSelections(r,"inlineCompletionPartialAccept"),e.revealPositionInCenterIfOutsideViewport(e.getPosition(),1)}finally{this._isAcceptingPartially=!1}if(r.source.provider.handlePartialAccept){const t=x.Q.fromPositions(r.range.getStartPosition(),X.W.ofText(h).addToPosition(a)),s=e.getModel().getValueInRange(t,1);r.source.provider.handlePartialAccept(r.source.inlineCompletions,r.sourceInlineCompletion,s.length,{kind:i})}}finally{r.source.removeRef()}}handleSuggestAccepted(e){const t=se(e.toSingleTextEdit(),this.textModel),i=this._computeAugmentation(t,void 0);if(!i)return;const s=i.completion.inlineCompletion;s.source.provider.handlePartialAccept?.(s.source.inlineCompletions,s.sourceInlineCompletion,t.text.length,{kind:2})}};var ye;function we(e,t,i){if(1===t.length)return[];const s=t[0],n=t.slice(1),r=i.range.getStartPosition(),o=i.range.getEndPosition(),a=e.getValueInRange(x.Q.fromPositions(s,o)),c=(0,P.tN)(s,r);if(c.lineNumber<1)return(0,Y.dz)(new Y.D7(`positionWithinTextEdit line number should be bigger than 0.\n\t\t\tInvalid subtraction between ${s.toString()} and ${r.toString()}`)),[];const l=function(e,t){let i="";const s=(0,R.en)(e);for(let n=t.lineNumber-1;n{const i=(0,P.OA)((0,P.tN)(t,r),o),s=e.getValueInRange(x.Q.fromPositions(t,i)),n=(0,R.Qp)(a,s),c=x.Q.fromPositions(t,t.delta(0,n));return new Q.WR(c,l)}))}function Re(e){const t=G.t9.createSortPermutation(e,(0,G.VE)((e=>e.range),x.Q.compareRangesUsingStarts)),i=new Q.mF(t.apply(e)).getNewRanges();return t.inverse().apply(i).map((e=>e.getEndPosition()))}Se=Ee([be(9,Ce._Y),be(10,ve.d),be(11,J.JZ)],Se),function(e){e[e.Undo=0]="Undo",e[e.Redo=1]="Redo",e[e.AcceptWord=2]="AcceptWord",e[e.Other=3]="Other"}(ye||(ye={}));var Le=i(29319),Te=i(38280),xe=i(90870);class ke extends d.jG{get selectedItem(){return this._currentSuggestItemInfo}constructor(e,t,i){super(),this.editor=e,this.suggestControllerPreselector=t,this.onWillAccept=i,this.isSuggestWidgetVisible=!1,this.isShiftKeyPressed=!1,this._isActive=!1,this._currentSuggestItemInfo=void 0,this._onDidSelectedItemChange=this._register(new w.vl),this.onDidSelectedItemChange=this._onDidSelectedItemChange.event,this._register(e.onKeyDown((e=>{e.shiftKey&&!this.isShiftKeyPressed&&(this.isShiftKeyPressed=!0,this.update(this._isActive))}))),this._register(e.onKeyUp((e=>{e.shiftKey&&this.isShiftKeyPressed&&(this.isShiftKeyPressed=!1,this.update(this._isActive))})));const s=xe.D.get(this.editor);if(s){this._register(s.registerSelector({priority:100,select:(e,t,i)=>{const n=this.editor.getModel();if(!n)return-1;const r=this.suggestControllerPreselector(),o=r?se(r,n):void 0;if(!o)return-1;const a=E.y.lift(t),c=i.map(((e,t)=>{const i=se(Ae.fromSuggestion(s,n,a,e,this.isShiftKeyPressed).toSingleTextEdit(),n);return{index:t,valid:ne(o,i),prefixLength:i.text.length,suggestItem:e}})).filter((e=>e&&e.valid&&e.prefixLength>0)),l=(0,j.Cn)(c,(0,G.VE)((e=>e.prefixLength),G.U9));return l?l.index:-1}}));let e=!1;const t=()=>{e||(e=!0,this._register(s.widget.value.onDidShow((()=>{this.isSuggestWidgetVisible=!0,this.update(!0)}))),this._register(s.widget.value.onDidHide((()=>{this.isSuggestWidgetVisible=!1,this.update(!1)}))),this._register(s.widget.value.onDidFocus((()=>{this.isSuggestWidgetVisible=!0,this.update(!0)}))))};this._register(w.Jh.once(s.model.onDidTrigger)((e=>{t()}))),this._register(s.onWillInsertSuggestItem((e=>{const t=this.editor.getPosition(),i=this.editor.getModel();if(!t||!i)return;const n=Ae.fromSuggestion(s,i,t,e.item,this.isShiftKeyPressed);this.onWillAccept(n)})))}this.update(this._isActive)}update(e){const t=this.getSuggestItemInfo();this._isActive===e&&function(e,t){if(e===t)return!0;if(!e||!t)return!1;return e.equals(t)}(this._currentSuggestItemInfo,t)||(this._isActive=e,this._currentSuggestItemInfo=t,this._onDidSelectedItemChange.fire())}getSuggestItemInfo(){const e=xe.D.get(this.editor);if(!e||!this.isSuggestWidgetVisible)return;const t=e.widget.value.getFocusedItem(),i=this.editor.getPosition(),s=this.editor.getModel();return t&&i&&s?Ae.fromSuggestion(e,s,i,t.item,this.isShiftKeyPressed):void 0}stopForceRenderingAbove(){const e=xe.D.get(this.editor);e?.stopForceRenderingAbove()}forceRenderingAbove(){const e=xe.D.get(this.editor);e?.forceRenderingAbove()}}class Ae{static fromSuggestion(e,t,i,s,n){let{insertText:r}=s.completion,o=!1;if(4&s.completion.insertTextRules){const e=(new Le.fr).parse(r);e.children.length<100&&Te.O.adjustWhitespace(t,i,!0,e),r=e.toString(),o=!0}const a=e.getOverwriteInfo(s,n);return new Ae(x.Q.fromPositions(i.delta(0,-a.overwriteBefore),i.delta(0,Math.max(a.overwriteAfter,0))),r,s.completion.kind,o)}constructor(e,t,i,s){this.range=e,this.insertText=t,this.completionItemKind=i,this.isSnippetText=s}equals(e){return this.range.equalsRange(e.range)&&this.insertText===e.insertText&&this.completionItemKind===e.completionItemKind&&this.isSnippetText===e.isSnippetText}toSelectedSuggestionInfo(){return new Z.GE(this.range,this.insertText,this.completionItemKind,this.isSnippetText)}toSingleTextEdit(){return new Q.WR(this.range,this.insertText)}}var Ne,Ie=i(78209),Oe=i(253),De=i(87213),Me=i(84001),Pe=i(32848),Fe=i(98031),Ue=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},He=function(e,t){return function(i,s){t(i,s,e)}};let Be=class extends d.jG{static{Ne=this}static{this.ID="editor.contrib.inlineCompletionsController"}static get(e){return e.getContribution(Ne.ID)}constructor(e,t,i,s,n,o,a,u,b,S){super(),this.editor=e,this._instantiationService=t,this._contextKeyService=i,this._configurationService=s,this._commandService=n,this._debounceService=o,this._languageFeaturesService=a,this._accessibilitySignalService=u,this._keybindingService=b,this._accessibilityService=S,this._editorObs=(0,C.Ud)(this.editor),this._positions=(0,r.un)(this,(e=>this._editorObs.selections.read(e)?.map((e=>e.getEndPosition()))??[new E.y(1,1)])),this._suggestWidgetAdaptor=this._register(new ke(this.editor,(()=>(this._editorObs.forceUpdate(),this.model.get()?.selectedInlineCompletion.get()?.toSingleTextEdit(void 0))),(e=>this._editorObs.forceUpdate((t=>{this.model.get()?.handleSuggestAccepted(e)}))))),this._suggestWidgetSelectedItem=(0,r.y0)(this,(e=>this._suggestWidgetAdaptor.onDidSelectedItemChange((()=>{this._editorObs.forceUpdate((t=>e(void 0)))}))),(()=>this._suggestWidgetAdaptor.selectedItem)),this._enabledInConfig=(0,r.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(62).enabled)),this._isScreenReaderEnabled=(0,r.y0)(this,this._accessibilityService.onDidChangeScreenReaderOptimized,(()=>this._accessibilityService.isScreenReaderOptimized())),this._editorDictationInProgress=(0,r.y0)(this,this._contextKeyService.onDidChangeContext,(()=>!0===this._contextKeyService.getContext(this.editor.getDomNode()).getValue("editorDictation.inProgress"))),this._enabled=(0,r.un)(this,(e=>this._enabledInConfig.read(e)&&(!this._isScreenReaderEnabled.read(e)||!this._editorDictationInProgress.read(e)))),this._debounceValue=this._debounceService.for(this._languageFeaturesService.inlineCompletionsProvider,"InlineCompletionsDebounce",{min:50,max:50}),this.model=(0,m.a0)(this,(e=>{if(this._editorObs.isReadonly.read(e))return;const t=this._editorObs.model.read(e);if(!t)return;return this._instantiationService.createInstance(Se,t,this._suggestWidgetSelectedItem,this._editorObs.versionId,this._positions,this._debounceValue,(0,r.y0)(this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(119).preview)),(0,r.y0)(this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(119).previewMode)),(0,r.y0)(this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(62).mode)),this._enabled)})).recomputeInitiallyAndOnChange(this._store),this._ghostTexts=(0,r.un)(this,(e=>{const t=this.model.read(e);return t?.ghostTexts.read(e)??[]})),this._stablizedGhostTexts=function(e,t){const i=(0,r.FY)("result",[]),s=[];return t.add((0,r.fm)((t=>{const n=e.read(t);(0,r.Rn)((e=>{if(n.length!==s.length){s.length=n.length;for(let e=0;et.set(n[i],e)))}))}))),i}(this._ghostTexts,this._store),this._ghostTextWidgets=(0,f.Rl)(this,this._stablizedGhostTexts,((e,t)=>t.add(this._instantiationService.createInstance(B,this.editor,{ghostText:e,minReservedLineCount:(0,r.lk)(0),targetTextModel:this.model.map((e=>e?.textModel))})))).recomputeInitiallyAndOnChange(this._store),this._playAccessibilitySignal=(0,r.Yd)(this),this._fontFamily=(0,r.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(62).fontFamily)),this._register(new l.p(this._contextKeyService,this.model)),this._register((0,C.jD)(this._editorObs.onDidType,((e,t)=>{this._enabled.get()&&this.model.get()?.trigger()}))),this._register(this._commandService.onDidExecuteCommand((t=>{new Set([v.Yh.Tab.id,v.Yh.DeleteLeft.id,v.Yh.DeleteRight.id,c.Wt,"acceptSelectedSuggestion"]).has(t.commandId)&&e.hasTextFocus()&&this._enabled.get()&&this._editorObs.forceUpdate((e=>{this.model.get()?.trigger(e)}))}))),this._register((0,C.jD)(this._editorObs.selections,((e,t)=>{t.some((e=>3===e.reason||"api"===e.source))&&this.model.get()?.stop()}))),this._register(this.editor.onDidBlurEditorWidget((()=>{this._contextKeyService.getContextKeyValue("accessibleViewIsShown")||this._configurationService.getValue("editor.inlineSuggest.keepOnBlur")||e.getOption(62).keepOnBlur||z.bo.dropDownVisible||(0,r.Rn)((e=>{this.model.get()?.stop(e)}))}))),this._register((0,r.fm)((e=>{const t=this.model.read(e)?.state.read(e);t?.suggestItem?t.primaryGhostText.lineCount>=2&&this._suggestWidgetAdaptor.forceRenderingAbove():this._suggestWidgetAdaptor.stopForceRenderingAbove()}))),this._register((0,d.s)((()=>{this._suggestWidgetAdaptor.stopForceRenderingAbove()})));const y=(0,f.ZX)(this,((e,t)=>{const i=this.model.read(e),s=i?.state.read(e);return this._suggestWidgetSelectedItem.get()?t:s?.inlineCompletion?.semanticId}));this._register((0,C.Qg)((0,r.un)((e=>(this._playAccessibilitySignal.read(e),y.read(e),{}))),(async(e,t,i)=>{const s=this.model.get(),n=s?.state.get();if(!n||!s)return;const o=s.textModel.getLineContent(n.primaryGhostText.lineNumber);await(0,g.wR)(50,(0,p.bs)(i)),await(0,r.oJ)(this._suggestWidgetSelectedItem,_.b0,(()=>!1),(0,p.bs)(i)),await this._accessibilitySignalService.playSignal(De.Rh.inlineSuggestion),this.editor.getOption(8)&&this._provideScreenReaderUpdate(n.primaryGhostText.renderForScreenReader(o))}))),this._register(new z.Pm(this.editor,this.model,this._instantiationService)),this._register(function(e){const t=new d.Cm,i=t.add((0,h.jh)());return t.add((0,r.fm)((t=>{i.setStyle(e.read(t))}))),t}((0,r.un)((e=>{const t=this._fontFamily.read(e);return""===t||"default"===t?"":`\n.monaco-editor .ghost-text-decoration,\n.monaco-editor .ghost-text-decoration-preview,\n.monaco-editor .ghost-text {\n\tfont-family: ${t};\n}`})))),this._register(this._configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration("accessibility.verbosity.inlineCompletions")&&this.editor.updateOptions({inlineCompletionsAccessibilityVerbose:this._configurationService.getValue("accessibility.verbosity.inlineCompletions")})}))),this.editor.updateOptions({inlineCompletionsAccessibilityVerbose:this._configurationService.getValue("accessibility.verbosity.inlineCompletions")})}playAccessibilitySignal(e){this._playAccessibilitySignal.trigger(e)}_provideScreenReaderUpdate(e){const t=this._contextKeyService.getContextKeyValue("accessibleViewIsShown"),i=this._keybindingService.lookupKeybinding("editor.action.accessibleView");let s;!t&&i&&this.editor.getOption(150)&&(s=(0,Ie.kg)("showAccessibleViewHint","Inspect this in the accessible view ({0})",i.getAriaLabel())),(0,u.xE)(s?e+", "+s:e)}shouldShowHoverAt(e){const t=this.model.get()?.primaryGhostText.get();return!!t&&t.parts.some((i=>e.containsPosition(new E.y(t.lineNumber,i.column))))}shouldShowHoverAtViewZone(e){return this._ghostTextWidgets.get()[0]?.ownsViewZone(e)??!1}};Be=Ne=Ue([He(1,Ce._Y),He(2,Pe.fN),He(3,Me.pG),He(4,ve.d),He(5,b.ILanguageFeatureDebounceService),He(6,S.ILanguageFeaturesService),He(7,De.Nt),He(8,Fe.b),He(9,Oe.j)],Be);var We=i(48116),Ve=i(27195);class ze extends s.ks{static{this.ID=c.PA}constructor(){super({id:ze.ID,label:Ie.kg("action.inlineSuggest.showNext","Show Next Inline Suggestion"),alias:"Show Next Inline Suggestion",precondition:Pe.M$.and(a.R.writable,l.p.inlineSuggestionVisible),kbOpts:{weight:100,primary:606}})}async run(e,t){const i=Be.get(t);i?.model.get()?.next()}}class Ge extends s.ks{static{this.ID=c.Vl}constructor(){super({id:Ge.ID,label:Ie.kg("action.inlineSuggest.showPrevious","Show Previous Inline Suggestion"),alias:"Show Previous Inline Suggestion",precondition:Pe.M$.and(a.R.writable,l.p.inlineSuggestionVisible),kbOpts:{weight:100,primary:604}})}async run(e,t){const i=Be.get(t);i?.model.get()?.previous()}}class je extends s.ks{constructor(){super({id:"editor.action.inlineSuggest.trigger",label:Ie.kg("action.inlineSuggest.trigger","Trigger Inline Suggestion"),alias:"Trigger Inline Suggestion",precondition:a.R.writable})}async run(e,t){const i=Be.get(t);await(0,o.fL)((async e=>{await(i?.model.get()?.triggerExplicitly(e)),i?.playAccessibilitySignal(e)}))}}class Ke extends s.ks{constructor(){super({id:"editor.action.inlineSuggest.acceptNextWord",label:Ie.kg("action.inlineSuggest.acceptNextWord","Accept Next Word Of Inline Suggestion"),alias:"Accept Next Word Of Inline Suggestion",precondition:Pe.M$.and(a.R.writable,l.p.inlineSuggestionVisible),kbOpts:{weight:101,primary:2065,kbExpr:Pe.M$.and(a.R.writable,l.p.inlineSuggestionVisible)},menuOpts:[{menuId:Ve.D8.InlineSuggestionToolbar,title:Ie.kg("acceptWord","Accept Word"),group:"primary",order:2}]})}async run(e,t){const i=Be.get(t);await(i?.model.get()?.acceptNextWord(i.editor))}}class Ye extends s.ks{constructor(){super({id:"editor.action.inlineSuggest.acceptNextLine",label:Ie.kg("action.inlineSuggest.acceptNextLine","Accept Next Line Of Inline Suggestion"),alias:"Accept Next Line Of Inline Suggestion",precondition:Pe.M$.and(a.R.writable,l.p.inlineSuggestionVisible),kbOpts:{weight:101},menuOpts:[{menuId:Ve.D8.InlineSuggestionToolbar,title:Ie.kg("acceptLine","Accept Line"),group:"secondary",order:2}]})}async run(e,t){const i=Be.get(t);await(i?.model.get()?.acceptNextLine(i.editor))}}class qe extends s.ks{constructor(){super({id:c.Wt,label:Ie.kg("action.inlineSuggest.accept","Accept Inline Suggestion"),alias:"Accept Inline Suggestion",precondition:l.p.inlineSuggestionVisible,menuOpts:[{menuId:Ve.D8.InlineSuggestionToolbar,title:Ie.kg("accept","Accept"),group:"primary",order:1}],kbOpts:{primary:2,weight:200,kbExpr:Pe.M$.and(l.p.inlineSuggestionVisible,a.R.tabMovesFocus.toNegated(),l.p.inlineSuggestionHasIndentationLessThanTabSize,We.ob.Visible.toNegated(),a.R.hoverFocused.toNegated())}})}async run(e,t){const i=Be.get(t);i&&(i.model.get()?.accept(i.editor),i.editor.focus())}}class $e extends s.ks{static{this.ID="editor.action.inlineSuggest.hide"}constructor(){super({id:$e.ID,label:Ie.kg("action.inlineSuggest.hide","Hide Inline Suggestion"),alias:"Hide Inline Suggestion",precondition:l.p.inlineSuggestionVisible,kbOpts:{weight:100,primary:9}})}async run(e,t){const i=Be.get(t);(0,r.Rn)((e=>{i?.model.get()?.stop(e)}))}}class Qe extends Ve.L{static{this.ID="editor.action.inlineSuggest.toggleAlwaysShowToolbar"}constructor(){super({id:Qe.ID,title:Ie.kg("action.inlineSuggest.alwaysShowToolbar","Always Show Toolbar"),f1:!1,precondition:void 0,menu:[{id:Ve.D8.InlineSuggestionToolbar,group:"secondary",order:10}],toggled:Pe.M$.equals("config.editor.inlineSuggest.showToolbar","always")})}async run(e,t){const i=e.get(Me.pG),s="always"===i.getValue("editor.inlineSuggest.showToolbar")?"onHover":"always";i.updateValue("editor.inlineSuggest.showToolbar",s)}}var Xe=i(16980),Ze=i(20492),Je=i(49099),et=i(90651),tt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},it=function(e,t){return function(i,s){t(i,s,e)}};class st{constructor(e,t,i){this.owner=e,this.range=t,this.controller=i}isValidForHoverAnchor(e){return 1===e.type&&this.range.startColumn<=e.range.startColumn&&this.range.endColumn>=e.range.endColumn}}let nt=class{constructor(e,t,i,s,n,r){this._editor=e,this._languageService=t,this._openerService=i,this.accessibilityService=s,this._instantiationService=n,this._telemetryService=r,this.hoverOrdinal=4}suggestHoverAnchor(e){const t=Be.get(this._editor);if(!t)return null;const i=e.target;if(8===i.type){const s=i.detail;if(t.shouldShowHoverAtViewZone(s.viewZoneId))return new n.mm(1e3,this,x.Q.fromPositions(this._editor.getModel().validatePosition(s.positionBefore||s.position)),e.event.posx,e.event.posy,!1)}if(7===i.type&&t.shouldShowHoverAt(i.range))return new n.mm(1e3,this,i.range,e.event.posx,e.event.posy,!1);if(6===i.type){if(i.detail.mightBeForeignElement&&t.shouldShowHoverAt(i.range))return new n.mm(1e3,this,i.range,e.event.posx,e.event.posy,!1)}return null}computeSync(e,t){if("onHover"!==this._editor.getOption(62).showToolbar)return[];const i=Be.get(this._editor);return i&&i.shouldShowHoverAt(e.range)?[new st(this,e.range,i)]:[]}renderHoverParts(e,t){const i=new d.Cm,s=t[0];this._telemetryService.publicLog2("inlineCompletionHover.shown"),this.accessibilityService.isScreenReaderOptimized()&&!this._editor.getOption(8)&&i.add(this.renderScreenReaderText(e,s));const o=s.controller.model.get(),a=this._instantiationService.createInstance(z.bo,this._editor,!1,(0,r.lk)(null),o.selectedInlineCompletionIndex,o.inlineCompletionsCount,o.activeCommands),c=a.getDomNode();e.fragment.appendChild(c),o.triggerExplicitly(),i.add(a);const l={hoverPart:s,hoverElement:c,dispose(){i.dispose()}};return new n.Ke([l])}renderScreenReaderText(e,t){const i=new d.Cm,s=h.$,n=s("div.hover-row.markdown-hover"),o=h.BC(n,s("div.hover-contents",{"aria-live":"assertive"})),a=i.add(new Ze.T({editor:this._editor},this._languageService,this._openerService));return i.add((0,r.fm)((s=>{const n=t.controller.model.read(s)?.primaryGhostText.read(s);if(n){const t=this._editor.getModel().getLineContent(n.lineNumber);(t=>{i.add(a.onDidRenderAsync((()=>{o.className="hover-contents code-hover-contents",e.onContentsChanged()})));const s=Ie.kg("inlineSuggestionFollows","Suggestion:"),n=i.add(a.render((new Xe.Bc).appendText(s).appendCodeblock("text",t)));o.replaceChildren(n.element)})(n.renderForScreenReader(t))}else h.Ln(o)}))),e.fragment.appendChild(n),i}};nt=tt([it(1,A.L),it(2,Je.C),it(3,Oe.j),it(4,Ce._Y),it(5,et.k)],nt);var rt=i(96282);(0,s.HW)(Be.ID,Be,3),(0,s.Fl)(je),(0,s.Fl)(ze),(0,s.Fl)(Ge),(0,s.Fl)(Ke),(0,s.Fl)(Ye),(0,s.Fl)(qe),(0,s.Fl)($e),(0,Ve.ug)(Qe),n.B2.register(nt),rt.Z.register(new class{})},80449:(e,t,i)=>{e.exports=i(17184)},80531:(e,t,i)=>{var s=i(68097),n=i(88834),r=i(12529),o=i(92061);e.exports=function(e,t){return t=s(t,e),null==(e=r(e,t))||delete e[o(n(t))]}},80537:(e,t,i)=>{"use strict";i.d(t,{cw:()=>c,jN:()=>a,nu:()=>o});var s=i(63591),n=i(79400),r=i(631);const o=(0,s.u1)("IWorkspaceEditService");class a{constructor(e){this.metadata=e}static convert(e){return e.edits.map((e=>{if(c.is(e))return c.lift(e);if(l.is(e))return l.lift(e);throw new Error("Unsupported edit")}))}}class c extends a{static is(e){return e instanceof c||(0,r.Gv)(e)&&n.r.isUri(e.resource)&&(0,r.Gv)(e.textEdit)}static lift(e){return e instanceof c?e:new c(e.resource,e.textEdit,e.versionId,e.metadata)}constructor(e,t,i=void 0,s){super(s),this.resource=e,this.textEdit=t,this.versionId=i}}class l extends a{static is(e){return e instanceof l||(0,r.Gv)(e)&&(Boolean(e.newResource)||Boolean(e.oldResource))}static lift(e){return e instanceof l?e:new l(e.oldResource,e.newResource,e.options,e.metadata)}constructor(e,t,i={},s){super(s),this.oldResource=e,this.newResource=t,this.options=i}}},80538:(e,t,i)=>{"use strict";i.d(t,{NN:()=>f,eS:()=>p,f9:()=>m,hE:()=>u,sv:()=>g});var s=i(25890),n=i(18447),r=i(64383),o=i(36456),a=i(31450),c=i(56942),l=i(79614);function h(e,t){return t.uri.scheme===e.uri.scheme||!(0,o.fV)(t.uri,o.ny.walkThroughSnippet,o.ny.vscodeChatCodeBlock,o.ny.vscodeChatCodeCompareBlock)}async function d(e,t,i,n,o){const a=i.ordered(e,n).map((i=>Promise.resolve(o(i,e,t)).then(void 0,(e=>{(0,r.M_)(e)})))),c=await Promise.all(a);return(0,s.Yc)(c.flat()).filter((t=>h(e,t)))}function u(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideDefinition(t,i,n)))}function g(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideDeclaration(t,i,n)))}function p(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideImplementation(t,i,n)))}function m(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideTypeDefinition(t,i,n)))}function f(e,t,i,s,n,r){return d(t,i,e,n,(async(e,t,i)=>{const n=(await e.provideReferences(t,i,{includeDeclaration:!0},r))?.filter((e=>h(t,e)));if(!s||!n||2!==n.length)return n;const o=(await e.provideReferences(t,i,{includeDeclaration:!1},r))?.filter((e=>h(t,e)));return o&&1===o.length?o:n}))}async function _(e){const t=await e(),i=new l.y4(t,""),s=i.references.map((e=>e.link));return i.dispose(),s}(0,a.ke)("_executeDefinitionProvider",((e,t,i)=>{const s=u(e.get(c.ILanguageFeaturesService).definitionProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeDefinitionProvider_recursive",((e,t,i)=>{const s=u(e.get(c.ILanguageFeaturesService).definitionProvider,t,i,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeTypeDefinitionProvider",((e,t,i)=>{const s=m(e.get(c.ILanguageFeaturesService).typeDefinitionProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeTypeDefinitionProvider_recursive",((e,t,i)=>{const s=m(e.get(c.ILanguageFeaturesService).typeDefinitionProvider,t,i,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeDeclarationProvider",((e,t,i)=>{const s=g(e.get(c.ILanguageFeaturesService).declarationProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeDeclarationProvider_recursive",((e,t,i)=>{const s=g(e.get(c.ILanguageFeaturesService).declarationProvider,t,i,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeReferenceProvider",((e,t,i)=>{const s=f(e.get(c.ILanguageFeaturesService).referenceProvider,t,i,!1,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeReferenceProvider_recursive",((e,t,i)=>{const s=f(e.get(c.ILanguageFeaturesService).referenceProvider,t,i,!1,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeImplementationProvider",((e,t,i)=>{const s=p(e.get(c.ILanguageFeaturesService).implementationProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeImplementationProvider_recursive",((e,t,i)=>{const s=p(e.get(c.ILanguageFeaturesService).implementationProvider,t,i,!0,n.XO.None);return _((()=>s))}))},80563:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1a7 7 0 1 0 0 14A7 7 0 0 0 8 1M6.03 6.72a.75.75 0 0 0-1.06 1.06l2.5 2.5a.75.75 0 0 0 1.06 0l2.5-2.5a.75.75 0 1 0-1.06-1.06L8 8.69z",clipRule:"evenodd"}))},80604:(e,t,i)=>{"use strict";i.d(t,{Z:()=>c});var s=i(27145),n=i(59284),r=i(46734),o=i(9296);const a=(0,i(69220).om)("card"),c=n.forwardRef((function(e,t){const{type:i="container",theme:c,view:l,size:h="m",children:d,className:u,onClick:g,disabled:p,selected:m}=e,f=(0,s.Tt)(e,["type","theme","view","size","children","className","onClick","disabled","selected"]),_="selection"===i,v="container"===i,C=("action"===i||_)&&Boolean(g)&&!p,E=v?"normal":void 0,b=v||_?"outlined":void 0,S=C?g:void 0,{onKeyDown:y}=(0,r.N)(g);return n.createElement(o.a,Object.assign({ref:t,role:C?"button":void 0,className:a({theme:c||E,view:l||b,type:i,selected:m,size:h,disabled:p,clickable:C},u),onClick:S,onKeyDown:C?y:void 0,tabIndex:C?0:void 0},f),d)}))},80624:(e,t,i)=>{"use strict";i.d(t,{BG:()=>r,IO:()=>a,Y:()=>o,eh:()=>n,pj:()=>l,qN:()=>c});class s{constructor(e,t){this._restrictedRenderingContextBrand=void 0,this._viewLayout=e,this.viewportData=t,this.scrollWidth=this._viewLayout.getScrollWidth(),this.scrollHeight=this._viewLayout.getScrollHeight(),this.visibleRange=this.viewportData.visibleRange,this.bigNumbersDelta=this.viewportData.bigNumbersDelta;const i=this._viewLayout.getCurrentViewport();this.scrollTop=i.top,this.scrollLeft=i.left,this.viewportWidth=i.width,this.viewportHeight=i.height}getScrolledTopFromAbsoluteTop(e){return e-this.scrollTop}getVerticalOffsetForLineNumber(e,t){return this._viewLayout.getVerticalOffsetForLineNumber(e,t)}getVerticalOffsetAfterLineNumber(e,t){return this._viewLayout.getVerticalOffsetAfterLineNumber(e,t)}getDecorationsInViewport(){return this.viewportData.getDecorationsInViewport()}}class n extends s{constructor(e,t,i){super(e,t),this._renderingContextBrand=void 0,this._viewLines=i}linesVisibleRangesForRange(e,t){return this._viewLines.linesVisibleRangesForRange(e,t)}visibleRangeForPosition(e){return this._viewLines.visibleRangeForPosition(e)}}class r{constructor(e,t,i,s){this.outsideRenderedLine=e,this.lineNumber=t,this.ranges=i,this.continuesOnNextLine=s}}class o{static from(e){const t=new Array(e.length);for(let i=0,s=e.length;i{"use strict";i.r(t),i.d(t,{EditorWorkerHost:()=>s});class s{static{this.CHANNEL_NAME="editorWorkerHost"}static getChannel(e){return e.getChannel(s.CHANNEL_NAME)}static setChannel(e,t){e.setChannel(s.CHANNEL_NAME,t)}}},80781:(e,t,i)=>{"use strict";i.r(t),i.d(t,{CancellationTokenSource:()=>Pc,Emitter:()=>Fc,KeyCode:()=>Uc,KeyMod:()=>Hc,MarkerSeverity:()=>Gc,MarkerTag:()=>jc,Position:()=>Bc,Range:()=>Wc,Selection:()=>Vc,SelectionDirection:()=>zc,Token:()=>Yc,Uri:()=>Kc,default:()=>Zc,editor:()=>qc,languages:()=>$c});var s={};i.r(s),i.d(s,{CancellationTokenSource:()=>Pc,Emitter:()=>Fc,KeyCode:()=>Uc,KeyMod:()=>Hc,MarkerSeverity:()=>Gc,MarkerTag:()=>jc,Position:()=>Bc,Range:()=>Wc,Selection:()=>Vc,SelectionDirection:()=>zc,Token:()=>Yc,Uri:()=>Kc,editor:()=>qc,languages:()=>$c});i(44915),i(88952),i(36999),i(58590),i(6438),i(94908),i(4836);var n=i(52555),r=(i(64215),i(31659),i(99822),i(40142),i(18864),i(32516),i(20961),i(40800),i(2183),i(58568),i(63867),i(61731),i(34175),i(44588),i(70552),i(48279),i(65877),i(81091),i(99312),i(62427),i(58466),i(56800),i(28449),i(57244),i(76440),i(80409),i(58145),i(40677),i(9948),i(84325),i(15040),i(75639),i(85117),i(14614),i(95200),i(50352),i(4519),i(85646),i(77047),i(6429),i(28211),i(59731),i(57377),i(50071),i(18278),i(98745),i(44798),i(10617),i(30936),i(57197),i(90870),i(10846),i(22890),i(98472),i(50166),i(68887),i(47210),i(79907),i(38728),i(46606),i(87908)),o=i(73848),a=i(25893),c=i(5662),l=i(91508),h=i(79400),d=i(28433),u=i(31450),g=i(80301),p=i(10146),m=i(90766),f=i(51929),_=i(80789),v=i(64383),C=i(36456),E=i(25890),b=i(78209);let S;function y(e,t){const i=globalThis.MonacoEnvironment;if(i){if("function"===typeof i.getWorker)return i.getWorker("workerMain.js",t);if("function"===typeof i.getWorkerUrl){const e=i.getWorkerUrl("workerMain.js",t);return new Worker(S?S.createScriptURL(e):e,{name:t,type:"module"})}}if(e){const i=function(e,t,i){const s=/^((http:)|(https:)|(file:)|(vscode-file:))/.test(t);if(s&&t.substring(0,globalThis.origin.length)!==globalThis.origin);else{const i=t.lastIndexOf("?"),s=t.lastIndexOf("#",i),n=i>0?new URLSearchParams(t.substring(i+1,~s?s:void 0)):new URLSearchParams;C.SJ.addSearchParam(n,!0,!0);t=n.toString()?`${t}?${n.toString()}#${e}`:`${t}#${e}`}0;const n=new Blob([(0,E.Yc)([`/*${e}*/`,i?`globalThis.MonacoEnvironment = { baseUrl: '${i}' };`:void 0,`globalThis._VSCODE_NLS_MESSAGES = ${JSON.stringify((0,b.Ec)())};`,`globalThis._VSCODE_NLS_LANGUAGE = ${JSON.stringify((0,b.i8)())};`,`globalThis._VSCODE_FILE_ROOT = '${globalThis._VSCODE_FILE_ROOT}';`,"const ttPolicy = globalThis.trustedTypes?.createPolicy('defaultWorkerFactory', { createScriptURL: value => value });","globalThis.workerttPolicy = ttPolicy;",`await import(ttPolicy?.createScriptURL('${t}') ?? '${t}');`,"globalThis.postMessage({ type: 'vscode-worker-ready' });",`/*${e}*/`]).join("")],{type:"application/javascript"});return URL.createObjectURL(n)}(t,e.toString(!0)),s=new Worker(S?S.createScriptURL(i):i,{name:t,type:"module"});return function(e){return new Promise(((t,i)=>{e.onmessage=function(i){"vscode-worker-ready"===i.data.type&&(e.onmessage=null,t(e))},e.onerror=i}))}(s)}throw new Error("You must define a function MonacoEnvironment.getWorkerUrl or MonacoEnvironment.getWorker")}S="object"===typeof self&&self.constructor&&"DedicatedWorkerGlobalScope"===self.constructor.name&&void 0!==globalThis.workerttPolicy?globalThis.workerttPolicy:(0,_.H)("defaultWorkerFactory",{createScriptURL:e=>e});class w extends c.jG{constructor(e,t,i,s,n,r){super(),this.id=i,this.label=s;const o=y(e,s);"function"===typeof o.then?this.worker=o:this.worker=Promise.resolve(o),this.postMessage(t,[]),this.worker.then((e=>{e.onmessage=function(e){n(e.data)},e.onmessageerror=r,"function"===typeof e.addEventListener&&e.addEventListener("error",r)})),this._register((0,c.s)((()=>{this.worker?.then((e=>{e.onmessage=null,e.onmessageerror=null,e.removeEventListener("error",r),e.terminate()})),this.worker=null})))}getId(){return this.id}postMessage(e,t){this.worker?.then((i=>{try{i.postMessage(e,t)}catch(s){(0,v.dz)(s),(0,v.dz)(new Error(`FAILED to post message to '${this.label}'-worker`,{cause:s}))}}))}}class R{constructor(e,t){this.amdModuleId=e,this.label=t,this.esmModuleLocation=C.zl.asBrowserUri(`${e}.esm.js`)}}class L{static{this.LAST_WORKER_ID=0}constructor(){this._webWorkerFailedBeforeError=!1}create(e,t,i){const s=++L.LAST_WORKER_ID;if(this._webWorkerFailedBeforeError)throw this._webWorkerFailedBeforeError;return new w(e.esmModuleLocation,e.amdModuleId,s,e.label||"anonymous"+s,t,(e=>{(0,f.logOnceWebWorkerWarning)(e),this._webWorkerFailedBeforeError=e,i(e)}))}}var T=i(36677),x=i(17469),k=i(16545),A=i(23750),N=i(90360),I=i(18801),O=i(78381),D=i(56942),M=i(41845),P=i(87723),F=i(86571),U=i(8597),H=i(47443),B=i(80718),W=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},V=function(e,t){return function(i,s){t(i,s,e)}};const z=3e5;function G(e,t){const i=e.getModel(t);return!!i&&!i.isTooLargeForSyncing()}let j=class extends c.jG{constructor(e,t,i,s,n,r){super(),this._languageConfigurationService=n,this._modelService=t,this._workerManager=this._register(new Y(e,this._modelService)),this._logService=s,this._register(r.linkProvider.register({language:"*",hasAccessToAllModels:!0},{provideLinks:async(e,t)=>{if(!G(this._modelService,e.uri))return Promise.resolve({links:[]});const i=await this._workerWithResources([e.uri]),s=await i.$computeLinks(e.uri.toString());return s&&{links:s}}})),this._register(r.completionProvider.register("*",new K(this._workerManager,i,this._modelService,this._languageConfigurationService)))}dispose(){super.dispose()}canComputeUnicodeHighlights(e){return G(this._modelService,e)}async computedUnicodeHighlights(e,t,i){return(await this._workerWithResources([e])).$computeUnicodeHighlights(e.toString(),t,i)}async computeDiff(e,t,i,s){const n=await this._workerWithResources([e,t],!0),r=await n.$computeDiff(e.toString(),t.toString(),i,s);if(!r)return null;return{identical:r.identical,quitEarly:r.quitEarly,changes:o(r.changes),moves:r.moves.map((e=>new M.t(new P.WL(new F.M(e[0],e[1]),new F.M(e[2],e[3])),o(e[4]))))};function o(e){return e.map((e=>new P.wm(new F.M(e[0],e[1]),new F.M(e[2],e[3]),e[4]?.map((e=>new P.q6(new T.Q(e[0],e[1],e[2],e[3]),new T.Q(e[4],e[5],e[6],e[7])))))))}}async computeMoreMinimalEdits(e,t,i=!1){if((0,E.EI)(t)){if(!G(this._modelService,e))return Promise.resolve(t);const s=O.W.create(),n=this._workerWithResources([e]).then((s=>s.$computeMoreMinimalEdits(e.toString(),t,i)));return n.finally((()=>this._logService.trace("FORMAT#computeMoreMinimalEdits",e.toString(!0),s.elapsed()))),Promise.race([n,(0,m.wR)(1e3).then((()=>t))])}return Promise.resolve(void 0)}canNavigateValueSet(e){return G(this._modelService,e)}async navigateValueSet(e,t,i){const s=this._modelService.getModel(e);if(!s)return null;const n=this._languageConfigurationService.getLanguageConfiguration(s.getLanguageId()).getWordDefinition(),r=n.source,o=n.flags;return(await this._workerWithResources([e])).$navigateValueSet(e.toString(),t,i,r,o)}canComputeWordRanges(e){return G(this._modelService,e)}async computeWordRanges(e,t){const i=this._modelService.getModel(e);if(!i)return Promise.resolve(null);const s=this._languageConfigurationService.getLanguageConfiguration(i.getLanguageId()).getWordDefinition(),n=s.source,r=s.flags;return(await this._workerWithResources([e])).$computeWordRanges(e.toString(),t,n,r)}async findSectionHeaders(e,t){return(await this._workerWithResources([e])).$findSectionHeaders(e.toString(),t)}async computeDefaultDocumentColors(e){return(await this._workerWithResources([e])).$computeDefaultDocumentColors(e.toString())}async _workerWithResources(e,t=!1){const i=await this._workerManager.withWorker();return await i.workerWithSyncedResources(e,t)}};j=W([V(1,A.IModelService),V(2,N.ITextResourceConfigurationService),V(3,I.rr),V(4,x.JZ),V(5,D.ILanguageFeaturesService)],j);class K{constructor(e,t,i,s){this.languageConfigurationService=s,this._debugDisplayName="wordbasedCompletions",this._workerManager=e,this._configurationService=t,this._modelService=i}async provideCompletionItems(e,t){const i=this._configurationService.getValue(e.uri,t,"editor");if("off"===i.wordBasedSuggestions)return;const s=[];if("currentDocument"===i.wordBasedSuggestions)G(this._modelService,e.uri)&&s.push(e.uri);else for(const h of this._modelService.getModels())G(this._modelService,h.uri)&&(h===e?s.unshift(h.uri):"allDocuments"!==i.wordBasedSuggestions&&h.getLanguageId()!==e.getLanguageId()||s.push(h.uri));if(0===s.length)return;const n=this.languageConfigurationService.getLanguageConfiguration(e.getLanguageId()).getWordDefinition(),r=e.getWordAtPosition(t),o=r?new T.Q(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn):T.Q.fromPositions(t),a=o.setEndPosition(t.lineNumber,t.column),c=await this._workerManager.withWorker(),l=await c.textualSuggest(s,r?.word,n);return l?{duration:l.duration,suggestions:l.words.map((e=>({kind:18,label:e,insertText:e,range:{insert:a,replace:o}})))}:void 0}}let Y=class extends c.jG{constructor(e,t){super(),this._workerDescriptor=e,this._modelService=t,this._editorWorkerClient=null,this._lastWorkerUsedTime=(new Date).getTime();this._register(new U.Be).cancelAndSet((()=>this._checkStopIdleWorker()),Math.round(15e4),a.G),this._register(this._modelService.onModelRemoved((e=>this._checkStopEmptyWorker())))}dispose(){this._editorWorkerClient&&(this._editorWorkerClient.dispose(),this._editorWorkerClient=null),super.dispose()}_checkStopEmptyWorker(){if(!this._editorWorkerClient)return;0===this._modelService.getModels().length&&(this._editorWorkerClient.dispose(),this._editorWorkerClient=null)}_checkStopIdleWorker(){if(!this._editorWorkerClient)return;(new Date).getTime()-this._lastWorkerUsedTime>z&&(this._editorWorkerClient.dispose(),this._editorWorkerClient=null)}withWorker(){return this._lastWorkerUsedTime=(new Date).getTime(),this._editorWorkerClient||(this._editorWorkerClient=new $(this._workerDescriptor,!1,this._modelService)),Promise.resolve(this._editorWorkerClient)}};Y=W([V(1,A.IModelService)],Y);class q{constructor(e){this._instance=e,this.proxy=this._instance}dispose(){this._instance.dispose()}setChannel(e,t){throw new Error("Not supported")}}let $=class extends c.jG{constructor(e,t,i){super(),this._workerDescriptor=e,this._disposed=!1,this._modelService=i,this._keepIdleModels=t,this._worker=null,this._modelManager=null}fhr(e,t){throw new Error("Not implemented!")}_getOrCreateWorker(){if(!this._worker)try{this._worker=this._register(function(e,t){const i="string"===typeof e?new R(e,t):e;return new f.SimpleWorkerClient(new L,i)}(this._workerDescriptor)),B.EditorWorkerHost.setChannel(this._worker,this._createEditorWorkerHost())}catch(e){(0,f.logOnceWebWorkerWarning)(e),this._worker=this._createFallbackLocalWorker()}return this._worker}async _getProxy(){try{const e=this._getOrCreateWorker().proxy;return await e.$ping(),e}catch(e){return(0,f.logOnceWebWorkerWarning)(e),this._worker=this._createFallbackLocalWorker(),this._worker.proxy}}_createFallbackLocalWorker(){return new q(new k.EditorSimpleWorker(this._createEditorWorkerHost(),null))}_createEditorWorkerHost(){return{$fhr:(e,t)=>this.fhr(e,t)}}_getOrCreateModelManager(e){return this._modelManager||(this._modelManager=this._register(new H.WorkerTextModelSyncClient(e,this._modelService,this._keepIdleModels))),this._modelManager}async workerWithSyncedResources(e,t=!1){if(this._disposed)return Promise.reject((0,v.aD)());const i=await this._getProxy();return this._getOrCreateModelManager(i).ensureSyncedResources(e,t),i}async textualSuggest(e,t,i){const s=await this.workerWithSyncedResources(e),n=i.source,r=i.flags;return s.$textualSuggest(e.map((e=>e.toString())),t,n,r)}dispose(){super.dispose(),this._disposed=!0}};$=W([V(2,A.IModelService)],$);var Q=i(41234),X=i(58925),Z=i(47612),J=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ee=function(e,t){return function(i,s){t(i,s,e)}};let te=class extends c.jG{constructor(e){super(),this._themeService=e,this._onWillCreateCodeEditor=this._register(new Q.vl),this._onCodeEditorAdd=this._register(new Q.vl),this.onCodeEditorAdd=this._onCodeEditorAdd.event,this._onCodeEditorRemove=this._register(new Q.vl),this.onCodeEditorRemove=this._onCodeEditorRemove.event,this._onWillCreateDiffEditor=this._register(new Q.vl),this._onDiffEditorAdd=this._register(new Q.vl),this.onDiffEditorAdd=this._onDiffEditorAdd.event,this._onDiffEditorRemove=this._register(new Q.vl),this.onDiffEditorRemove=this._onDiffEditorRemove.event,this._decorationOptionProviders=new Map,this._codeEditorOpenHandlers=new X.w,this._modelProperties=new Map,this._codeEditors=Object.create(null),this._diffEditors=Object.create(null),this._globalStyleSheet=null}willCreateCodeEditor(){this._onWillCreateCodeEditor.fire()}addCodeEditor(e){this._codeEditors[e.getId()]=e,this._onCodeEditorAdd.fire(e)}removeCodeEditor(e){delete this._codeEditors[e.getId()]&&this._onCodeEditorRemove.fire(e)}listCodeEditors(){return Object.keys(this._codeEditors).map((e=>this._codeEditors[e]))}willCreateDiffEditor(){this._onWillCreateDiffEditor.fire()}addDiffEditor(e){this._diffEditors[e.getId()]=e,this._onDiffEditorAdd.fire(e)}listDiffEditors(){return Object.keys(this._diffEditors).map((e=>this._diffEditors[e]))}getFocusedCodeEditor(){let e=null;const t=this.listCodeEditors();for(const i of t){if(i.hasTextFocus())return i;i.hasWidgetFocus()&&(e=i)}return e}removeDecorationType(e){const t=this._decorationOptionProviders.get(e);t&&(t.refCount--,t.refCount<=0&&(this._decorationOptionProviders.delete(e),t.dispose(),this.listCodeEditors().forEach((t=>t.removeDecorationsByType(e)))))}setModelProperty(e,t,i){const s=e.toString();let n;this._modelProperties.has(s)?n=this._modelProperties.get(s):(n=new Map,this._modelProperties.set(s,n)),n.set(t,i)}getModelProperty(e,t){const i=e.toString();if(this._modelProperties.has(i)){return this._modelProperties.get(i).get(t)}}async openCodeEditor(e,t,i){for(const s of this._codeEditorOpenHandlers){const n=await s(e,t,i);if(null!==n)return n}return null}registerCodeEditorOpenHandler(e){const t=this._codeEditorOpenHandlers.unshift(e);return(0,c.s)(t)}};te=J([ee(0,Z.Gy)],te);var ie=i(32848),se=i(14718),ne=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},re=function(e,t){return function(i,s){t(i,s,e)}};let oe=class extends te{constructor(e,t){super(t),this._register(this.onCodeEditorAdd((()=>this._checkContextKey()))),this._register(this.onCodeEditorRemove((()=>this._checkContextKey()))),this._editorIsOpen=e.createKey("editorIsOpen",!1),this._activeCodeEditor=null,this._register(this.registerCodeEditorOpenHandler((async(e,t,i)=>t?this.doOpenEditor(t,e):null)))}_checkContextKey(){let e=!1;for(const t of this.listCodeEditors())if(!t.isSimpleWidget){e=!0;break}this._editorIsOpen.set(e)}setActiveCodeEditor(e){this._activeCodeEditor=e}getActiveCodeEditor(){return this._activeCodeEditor}doOpenEditor(e,t){if(!this.findModel(e,t.resource)){if(t.resource){const i=t.resource.scheme;if(i===C.ny.http||i===C.ny.https)return(0,U.CE)(t.resource.toString()),e}return null}const i=t.options?t.options.selection:null;if(i)if("number"===typeof i.endLineNumber&&"number"===typeof i.endColumn)e.setSelection(i),e.revealRangeInCenter(i,1);else{const t={lineNumber:i.startLineNumber,column:i.startColumn};e.setPosition(t),e.revealPositionInCenter(t,1)}return e}findModel(e,t){const i=e.getModel();return i&&i.uri.toString()!==t.toString()?null:i}};oe=ne([re(0,ie.fN),re(1,Z.Gy)],oe),(0,se.v)(g.T,oe,0);var ae=i(63591);const ce=(0,ae.u1)("layoutService");var le=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},he=function(e,t){return function(i,s){t(i,s,e)}};let de=class{get mainContainer(){return(0,E.Fy)(this._codeEditorService.listCodeEditors())?.getContainerDomNode()??a.G.document.body}get activeContainer(){const e=this._codeEditorService.getFocusedCodeEditor()??this._codeEditorService.getActiveCodeEditor();return e?.getContainerDomNode()??this.mainContainer}get mainContainerDimension(){return U.tG(this.mainContainer)}get activeContainerDimension(){return U.tG(this.activeContainer)}get containers(){return(0,E.Yc)(this._codeEditorService.listCodeEditors().map((e=>e.getContainerDomNode())))}getContainer(){return this.activeContainer}whenContainerStylesLoaded(){}focus(){this._codeEditorService.getFocusedCodeEditor()?.focus()}constructor(e){this._codeEditorService=e,this.onDidLayoutMainContainer=Q.Jh.None,this.onDidLayoutActiveContainer=Q.Jh.None,this.onDidLayoutContainer=Q.Jh.None,this.onDidChangeActiveContainer=Q.Jh.None,this.onDidAddContainer=Q.Jh.None,this.mainContainerOffset={top:0,quickPickTop:0},this.activeContainerOffset={top:0,quickPickTop:0}}};de=le([he(0,g.T)],de);let ue=class extends de{get mainContainer(){return this._container}constructor(e,t){super(t),this._container=e}};ue=le([he(1,g.T)],ue),(0,se.v)(ce,de,1);var ge=i(42291),pe=i(59599),me=i(58591),fe=i(47579),_e=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ve=function(e,t){return function(i,s){t(i,s,e)}};const Ce=!1;function Ee(e){return e.scheme===C.ny.file?e.fsPath:e.path}let be=0;class Se{constructor(e,t,i,s,n,r,o){this.id=++be,this.type=0,this.actual=e,this.label=e.label,this.confirmBeforeUndo=e.confirmBeforeUndo||!1,this.resourceLabel=t,this.strResource=i,this.resourceLabels=[this.resourceLabel],this.strResources=[this.strResource],this.groupId=s,this.groupOrder=n,this.sourceId=r,this.sourceOrder=o,this.isValid=!0}setValid(e){this.isValid=e}toString(){return`[id:${this.id}] [group:${this.groupId}] [${this.isValid?" VALID":"INVALID"}] ${this.actual.constructor.name} - ${this.actual}`}}class ye{constructor(e,t){this.resourceLabel=e,this.reason=t}}class we{constructor(){this.elements=new Map}createMessage(){const e=[],t=[];for(const[,s]of this.elements){(0===s.reason?e:t).push(s.resourceLabel)}const i=[];return e.length>0&&i.push(b.kg({key:"externalRemoval",comment:["{0} is a list of filenames"]},"The following files have been closed and modified on disk: {0}.",e.join(", "))),t.length>0&&i.push(b.kg({key:"noParallelUniverses",comment:["{0} is a list of filenames"]},"The following files have been modified in an incompatible way: {0}.",t.join(", "))),i.join("\n")}get size(){return this.elements.size}has(e){return this.elements.has(e)}set(e,t){this.elements.set(e,t)}delete(e){return this.elements.delete(e)}}class Re{constructor(e,t,i,s,n,r,o){this.id=++be,this.type=1,this.actual=e,this.label=e.label,this.confirmBeforeUndo=e.confirmBeforeUndo||!1,this.resourceLabels=t,this.strResources=i,this.groupId=s,this.groupOrder=n,this.sourceId=r,this.sourceOrder=o,this.removedResources=null,this.invalidatedResources=null}canSplit(){return"function"===typeof this.actual.split}removeResource(e,t,i){this.removedResources||(this.removedResources=new we),this.removedResources.has(t)||this.removedResources.set(t,new ye(e,i))}setValid(e,t,i){i?this.invalidatedResources&&(this.invalidatedResources.delete(t),0===this.invalidatedResources.size&&(this.invalidatedResources=null)):(this.invalidatedResources||(this.invalidatedResources=new we),this.invalidatedResources.has(t)||this.invalidatedResources.set(t,new ye(e,0)))}toString(){return`[id:${this.id}] [group:${this.groupId}] [${this.invalidatedResources?"INVALID":" VALID"}] ${this.actual.constructor.name} - ${this.actual}`}}class Le{constructor(e,t){this.resourceLabel=e,this.strResource=t,this._past=[],this._future=[],this.locked=!1,this.versionId=1}dispose(){for(const e of this._past)1===e.type&&e.removeResource(this.resourceLabel,this.strResource,0);for(const e of this._future)1===e.type&&e.removeResource(this.resourceLabel,this.strResource,0);this.versionId++}toString(){const e=[];e.push(`* ${this.strResource}:`);for(let t=0;t=0;t--)e.push(` * [REDO] ${this._future[t]}`);return e.join("\n")}flushAllElements(){this._past=[],this._future=[],this.versionId++}_setElementValidFlag(e,t){1===e.type?e.setValid(this.resourceLabel,this.strResource,t):e.setValid(t)}setElementsValidFlag(e,t){for(const i of this._past)t(i.actual)&&this._setElementValidFlag(i,e);for(const i of this._future)t(i.actual)&&this._setElementValidFlag(i,e)}pushElement(e){for(const t of this._future)1===t.type&&t.removeResource(this.resourceLabel,this.strResource,1);this._future=[],this._past.push(e),this.versionId++}createSnapshot(e){const t=[];for(let i=0,s=this._past.length;i=0;i--)t.push(this._future[i].id);return new fe.To(e,t)}restoreSnapshot(e){const t=e.elements.length;let i=!0,s=0,n=-1;for(let o=0,a=this._past.length;o=t||r.id!==e.elements[s])&&(i=!1,n=0),i||1!==r.type||r.removeResource(this.resourceLabel,this.strResource,0)}let r=-1;for(let o=this._future.length-1;o>=0;o--,s++){const n=this._future[o];i&&(s>=t||n.id!==e.elements[s])&&(i=!1,r=o),i||1!==n.type||n.removeResource(this.resourceLabel,this.strResource,0)}-1!==n&&(this._past=this._past.slice(0,n)),-1!==r&&(this._future=this._future.slice(r+1)),this.versionId++}getElements(){const e=[],t=[];for(const i of this._past)e.push(i.actual);for(const i of this._future)t.push(i.actual);return{past:e,future:t}}getClosestPastElement(){return 0===this._past.length?null:this._past[this._past.length-1]}getSecondClosestPastElement(){return this._past.length<2?null:this._past[this._past.length-2]}getClosestFutureElement(){return 0===this._future.length?null:this._future[this._future.length-1]}hasPastElements(){return this._past.length>0}hasFutureElements(){return this._future.length>0}splitPastWorkspaceElement(e,t){for(let i=this._past.length-1;i>=0;i--)if(this._past[i]===e){t.has(this.strResource)?this._past[i]=t.get(this.strResource):this._past.splice(i,1);break}this.versionId++}splitFutureWorkspaceElement(e,t){for(let i=this._future.length-1;i>=0;i--)if(this._future[i]===e){t.has(this.strResource)?this._future[i]=t.get(this.strResource):this._future.splice(i,1);break}this.versionId++}moveBackward(e){this._past.pop(),this._future.push(e),this.versionId++}moveForward(e){this._future.pop(),this._past.push(e),this.versionId++}}class Te{constructor(e){this.editStacks=e,this._versionIds=[];for(let t=0,i=this.editStacks.length;tt.sourceOrder)&&(t=r,i=s))}return[t,i]}canUndo(e){if(e instanceof fe.Ym){const[,t]=this._findClosestUndoElementWithSource(e.id);return!!t}const t=this.getUriComparisonKey(e);if(this._editStacks.has(t)){return this._editStacks.get(t).hasPastElements()}return!1}_onError(e,t){(0,v.dz)(e);for(const i of t.strResources)this.removeElements(i);this._notificationService.error(e)}_acquireLocks(e){for(const t of e.editStacks)if(t.locked)throw new Error("Cannot acquire edit stack lock");for(const t of e.editStacks)t.locked=!0;return()=>{for(const t of e.editStacks)t.locked=!1}}_safeInvokeWithLocks(e,t,i,s,n){const r=this._acquireLocks(i);let o;try{o=t()}catch(a){return r(),s.dispose(),this._onError(a,e)}return o?o.then((()=>(r(),s.dispose(),n())),(t=>(r(),s.dispose(),this._onError(t,e)))):(r(),s.dispose(),n())}async _invokeWorkspacePrepare(e){if("undefined"===typeof e.actual.prepareUndoRedo)return c.jG.None;const t=e.actual.prepareUndoRedo();return"undefined"===typeof t?c.jG.None:t}_invokeResourcePrepare(e,t){if(1!==e.actual.type||"undefined"===typeof e.actual.prepareUndoRedo)return t(c.jG.None);const i=e.actual.prepareUndoRedo();return i?(0,c.Xm)(i)?t(i):i.then((e=>t(e))):t(c.jG.None)}_getAffectedEditStacks(e){const t=[];for(const i of e.strResources)t.push(this._editStacks.get(i)||xe);return new Te(t)}_tryToSplitAndUndo(e,t,i,s){if(t.canSplit())return this._splitPastWorkspaceElement(t,i),this._notificationService.warn(s),new Ae(this._undo(e,0,!0));for(const n of t.strResources)this.removeElements(n);return this._notificationService.warn(s),new Ae}_checkWorkspaceUndo(e,t,i,s){if(t.removedResources)return this._tryToSplitAndUndo(e,t,t.removedResources,b.kg({key:"cannotWorkspaceUndo",comment:["{0} is a label for an operation. {1} is another message."]},"Could not undo '{0}' across all files. {1}",t.label,t.removedResources.createMessage()));if(s&&t.invalidatedResources)return this._tryToSplitAndUndo(e,t,t.invalidatedResources,b.kg({key:"cannotWorkspaceUndo",comment:["{0} is a label for an operation. {1} is another message."]},"Could not undo '{0}' across all files. {1}",t.label,t.invalidatedResources.createMessage()));const n=[];for(const o of i.editStacks)o.getClosestPastElement()!==t&&n.push(o.resourceLabel);if(n.length>0)return this._tryToSplitAndUndo(e,t,null,b.kg({key:"cannotWorkspaceUndoDueToChanges",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not undo '{0}' across all files because changes were made to {1}",t.label,n.join(", ")));const r=[];for(const o of i.editStacks)o.locked&&r.push(o.resourceLabel);return r.length>0?this._tryToSplitAndUndo(e,t,null,b.kg({key:"cannotWorkspaceUndoDueToInProgressUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not undo '{0}' across all files because there is already an undo or redo operation running on {1}",t.label,r.join(", "))):i.isValid()?null:this._tryToSplitAndUndo(e,t,null,b.kg({key:"cannotWorkspaceUndoDueToInMeantimeUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not undo '{0}' across all files because an undo or redo operation occurred in the meantime",t.label))}_workspaceUndo(e,t,i){const s=this._getAffectedEditStacks(t),n=this._checkWorkspaceUndo(e,t,s,!1);return n?n.returnValue:this._confirmAndExecuteWorkspaceUndo(e,t,s,i)}_isPartOfUndoGroup(e){if(!e.groupId)return!1;for(const[,t]of this._editStacks){const i=t.getClosestPastElement();if(i){if(i===e){const i=t.getSecondClosestPastElement();if(i&&i.groupId===e.groupId)return!0}if(i.groupId===e.groupId)return!0}}return!1}async _confirmAndExecuteWorkspaceUndo(e,t,i,s){if(t.canSplit()&&!this._isPartOfUndoGroup(t)){let n;!function(e){e[e.All=0]="All",e[e.This=1]="This",e[e.Cancel=2]="Cancel"}(n||(n={}));const{result:r}=await this._dialogService.prompt({type:ge.A.Info,message:b.kg("confirmWorkspace","Would you like to undo '{0}' across all files?",t.label),buttons:[{label:b.kg({key:"ok",comment:["{0} denotes a number that is > 1, && denotes a mnemonic"]},"&&Undo in {0} Files",i.editStacks.length),run:()=>n.All},{label:b.kg({key:"nok",comment:["&& denotes a mnemonic"]},"Undo this &&File"),run:()=>n.This}],cancelButton:{run:()=>n.Cancel}});if(r===n.Cancel)return;if(r===n.This)return this._splitPastWorkspaceElement(t,null),this._undo(e,0,!0);const o=this._checkWorkspaceUndo(e,t,i,!1);if(o)return o.returnValue;s=!0}let n;try{n=await this._invokeWorkspacePrepare(t)}catch(o){return this._onError(o,t)}const r=this._checkWorkspaceUndo(e,t,i,!0);if(r)return n.dispose(),r.returnValue;for(const a of i.editStacks)a.moveBackward(t);return this._safeInvokeWithLocks(t,(()=>t.actual.undo()),i,n,(()=>this._continueUndoInGroup(t.groupId,s)))}_resourceUndo(e,t,i){if(t.isValid){if(!e.locked)return this._invokeResourcePrepare(t,(s=>(e.moveBackward(t),this._safeInvokeWithLocks(t,(()=>t.actual.undo()),new Te([e]),s,(()=>this._continueUndoInGroup(t.groupId,i))))));{const e=b.kg({key:"cannotResourceUndoDueToInProgressUndoRedo",comment:["{0} is a label for an operation."]},"Could not undo '{0}' because there is already an undo or redo operation running.",t.label);this._notificationService.warn(e)}}else e.flushAllElements()}_findClosestUndoElementInGroup(e){if(!e)return[null,null];let t=null,i=null;for(const[s,n]of this._editStacks){const r=n.getClosestPastElement();r&&(r.groupId===e&&(!t||r.groupOrder>t.groupOrder)&&(t=r,i=s))}return[t,i]}_continueUndoInGroup(e,t){if(!e)return;const[,i]=this._findClosestUndoElementInGroup(e);return i?this._undo(i,0,t):void 0}undo(e){if(e instanceof fe.Ym){const[,t]=this._findClosestUndoElementWithSource(e.id);return t?this._undo(t,e.id,!1):void 0}return"string"===typeof e?this._undo(e,0,!1):this._undo(this.getUriComparisonKey(e),0,!1)}_undo(e,t=0,i){if(!this._editStacks.has(e))return;const s=this._editStacks.get(e),n=s.getClosestPastElement();if(!n)return;if(n.groupId){const[e,s]=this._findClosestUndoElementInGroup(n.groupId);if(n!==e&&s)return this._undo(s,t,i)}if((n.sourceId!==t||n.confirmBeforeUndo)&&!i)return this._confirmAndContinueUndo(e,t,n);try{return 1===n.type?this._workspaceUndo(e,n,i):this._resourceUndo(s,n,i)}finally{Ce}}async _confirmAndContinueUndo(e,t,i){if((await this._dialogService.confirm({message:b.kg("confirmDifferentSource","Would you like to undo '{0}'?",i.label),primaryButton:b.kg({key:"confirmDifferentSource.yes",comment:["&& denotes a mnemonic"]},"&&Yes"),cancelButton:b.kg("confirmDifferentSource.no","No")})).confirmed)return this._undo(e,t,!0)}_findClosestRedoElementWithSource(e){if(!e)return[null,null];let t=null,i=null;for(const[s,n]of this._editStacks){const r=n.getClosestFutureElement();r&&(r.sourceId===e&&(!t||r.sourceOrder0)return this._tryToSplitAndRedo(e,t,null,b.kg({key:"cannotWorkspaceRedoDueToChanges",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not redo '{0}' across all files because changes were made to {1}",t.label,n.join(", ")));const r=[];for(const o of i.editStacks)o.locked&&r.push(o.resourceLabel);return r.length>0?this._tryToSplitAndRedo(e,t,null,b.kg({key:"cannotWorkspaceRedoDueToInProgressUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not redo '{0}' across all files because there is already an undo or redo operation running on {1}",t.label,r.join(", "))):i.isValid()?null:this._tryToSplitAndRedo(e,t,null,b.kg({key:"cannotWorkspaceRedoDueToInMeantimeUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not redo '{0}' across all files because an undo or redo operation occurred in the meantime",t.label))}_workspaceRedo(e,t){const i=this._getAffectedEditStacks(t),s=this._checkWorkspaceRedo(e,t,i,!1);return s?s.returnValue:this._executeWorkspaceRedo(e,t,i)}async _executeWorkspaceRedo(e,t,i){let s;try{s=await this._invokeWorkspacePrepare(t)}catch(r){return this._onError(r,t)}const n=this._checkWorkspaceRedo(e,t,i,!0);if(n)return s.dispose(),n.returnValue;for(const o of i.editStacks)o.moveForward(t);return this._safeInvokeWithLocks(t,(()=>t.actual.redo()),i,s,(()=>this._continueRedoInGroup(t.groupId)))}_resourceRedo(e,t){if(t.isValid){if(!e.locked)return this._invokeResourcePrepare(t,(i=>(e.moveForward(t),this._safeInvokeWithLocks(t,(()=>t.actual.redo()),new Te([e]),i,(()=>this._continueRedoInGroup(t.groupId))))));{const e=b.kg({key:"cannotResourceRedoDueToInProgressUndoRedo",comment:["{0} is a label for an operation."]},"Could not redo '{0}' because there is already an undo or redo operation running.",t.label);this._notificationService.warn(e)}}else e.flushAllElements()}_findClosestRedoElementInGroup(e){if(!e)return[null,null];let t=null,i=null;for(const[s,n]of this._editStacks){const r=n.getClosestFutureElement();r&&(r.groupId===e&&(!t||r.groupOrder=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},je=function(e,t){return function(i,s){t(i,s,e)}};const Ke=U.$;let Ye=class extends Fe.x{get _targetWindow(){return U.zk(this._target.targetElements[0])}get _targetDocumentElement(){return U.zk(this._target.targetElements[0]).document.documentElement}get isDisposed(){return this._isDisposed}get isMouseIn(){return this._lockMouseTracker.isMouseIn}get domNode(){return this._hover.containerDomNode}get onDispose(){return this._onDispose.event}get onRequestLayout(){return this._onRequestLayout.event}get anchor(){return 2===this._hoverPosition?0:1}get x(){return this._x}get y(){return this._y}get isLocked(){return this._isLocked}set isLocked(e){this._isLocked!==e&&(this._isLocked=e,this._hoverContainer.classList.toggle("locked",this._isLocked))}constructor(e,t,i,s,n,o){super(),this._keybindingService=t,this._configurationService=i,this._openerService=s,this._instantiationService=n,this._accessibilityService=o,this._messageListeners=new c.Cm,this._isDisposed=!1,this._forcePosition=!1,this._x=0,this._y=0,this._isLocked=!1,this._enableFocusTraps=!1,this._addedFocusTrap=!1,this._onDispose=this._register(new Q.vl),this._onRequestLayout=this._register(new Q.vl),this._linkHandler=e.linkHandler||(t=>(0,He.i)(this._openerService,t,(0,Be.VS)(e.content)?e.content.isTrusted:void 0)),this._target="targetElements"in e.target?e.target:new $e(e.target),this._hoverPointer=e.appearance?.showPointer?Ke("div.workbench-hover-pointer"):void 0,this._hover=this._register(new Pe.N4),this._hover.containerDomNode.classList.add("workbench-hover","fadeIn"),e.appearance?.compact&&this._hover.containerDomNode.classList.add("workbench-hover","compact"),e.appearance?.skipFadeInAnimation&&this._hover.containerDomNode.classList.add("skip-fade-in"),e.additionalClasses&&this._hover.containerDomNode.classList.add(...e.additionalClasses),e.position?.forcePosition&&(this._forcePosition=!0),e.trapFocus&&(this._enableFocusTraps=!0),this._hoverPosition=e.position?.hoverPosition??3,this.onmousedown(this._hover.containerDomNode,(e=>e.stopPropagation())),this.onkeydown(this._hover.containerDomNode,(e=>{e.equals(9)&&this.dispose()})),this._register(U.ko(this._targetWindow,"blur",(()=>this.dispose())));const a=Ke("div.hover-row.markdown-hover"),l=Ke("div.hover-contents");if("string"===typeof e.content)l.textContent=e.content,l.style.whiteSpace="pre-wrap";else if(U.sb(e.content))l.appendChild(e.content),l.classList.add("html-hover-contents");else{const t=e.content,i=this._instantiationService.createInstance(He.T,{codeBlockFontFamily:this._configurationService.getValue("editor").fontFamily||r.jU.fontFamily}),{element:s}=i.render(t,{actionHandler:{callback:e=>this._linkHandler(e),disposables:this._messageListeners},asyncRenderCallback:()=>{l.classList.add("code-hover-contents"),this.layout(),this._onRequestLayout.fire()}});l.appendChild(s)}if(a.appendChild(l),this._hover.contentsDomNode.appendChild(a),e.actions&&e.actions.length>0){const t=Ke("div.hover-row.status-bar"),i=Ke("div.actions");e.actions.forEach((e=>{const t=this._keybindingService.lookupKeybinding(e.commandId),s=t?t.getLabel():null;Pe.jQ.render(i,{label:e.label,commandId:e.commandId,run:t=>{e.run(t),this.dispose()},iconClass:e.iconClass},s)})),t.appendChild(i),this._hover.containerDomNode.appendChild(t)}let h;if(this._hoverContainer=Ke("div.workbench-hover-container"),this._hoverPointer&&this._hoverContainer.appendChild(this._hoverPointer),this._hoverContainer.appendChild(this._hover.containerDomNode),h=!(e.actions&&e.actions.length>0)&&(void 0===e.persistence?.hideOnHover?"string"===typeof e.content||(0,Be.VS)(e.content)&&!e.content.value.includes("](")&&!e.content.value.includes(""):e.persistence.hideOnHover),e.appearance?.showHoverHint){const e=Ke("div.hover-row.status-bar"),t=Ke("div.info");t.textContent=(0,b.kg)("hoverhint","Hold {0} key to mouse over",We.zx?"Option":"Alt"),e.appendChild(t),this._hover.containerDomNode.appendChild(e)}const d=[...this._target.targetElements];h||d.push(this._hoverContainer);const u=this._register(new qe(d));if(this._register(u.onMouseOut((()=>{this._isLocked||this.dispose()}))),h){const e=[...this._target.targetElements,this._hoverContainer];this._lockMouseTracker=this._register(new qe(e)),this._register(this._lockMouseTracker.onMouseOut((()=>{this._isLocked||this.dispose()})))}else this._lockMouseTracker=u}addFocusTrap(){if(!this._enableFocusTraps||this._addedFocusTrap)return;this._addedFocusTrap=!0;const e=this._hover.containerDomNode,t=this.findLastFocusableChild(this._hover.containerDomNode);if(t){const i=U.Hs(this._hoverContainer,Ke("div")),s=U.BC(this._hoverContainer,Ke("div"));i.tabIndex=0,s.tabIndex=0,this._register(U.ko(s,"focus",(t=>{e.focus(),t.preventDefault()}))),this._register(U.ko(i,"focus",(e=>{t.focus(),e.preventDefault()})))}}findLastFocusableChild(e){if(e.hasChildNodes())for(let t=0;t=0)return e}const s=this.findLastFocusableChild(i);if(s)return s}}render(e){e.appendChild(this._hoverContainer);const t=this._hoverContainer.contains(this._hoverContainer.ownerDocument.activeElement)&&(0,Pe.vr)(!0===this._configurationService.getValue("accessibility.verbosity.hover")&&this._accessibilityService.isScreenReaderOptimized(),this._keybindingService.lookupKeybinding("editor.action.accessibleView")?.getAriaLabel());t&&(0,ze.h5)(t),this.layout(),this.addFocusTrap()}layout(){this._hover.containerDomNode.classList.remove("right-aligned"),this._hover.contentsDomNode.style.maxHeight="";const e=this._target.targetElements.map((e=>(e=>{const t=U.mU(e),i=e.getBoundingClientRect();return{top:i.top*t,bottom:i.bottom*t,right:i.right*t,left:i.left*t}})(e))),{top:t,right:i,bottom:s,left:n}=e[0],r=i-n,o=s-t,a={top:t,right:i,bottom:s,left:n,width:r,height:o,center:{x:n+r/2,y:t+o/2}};if(this.adjustHorizontalHoverPosition(a),this.adjustVerticalHoverPosition(a),this.adjustHoverMaxHeight(a),this._hoverContainer.style.padding="",this._hoverContainer.style.margin="",this._hoverPointer){switch(this._hoverPosition){case 1:a.left+=3,a.right+=3,this._hoverContainer.style.paddingLeft="3px",this._hoverContainer.style.marginLeft="-3px";break;case 0:a.left-=3,a.right-=3,this._hoverContainer.style.paddingRight="3px",this._hoverContainer.style.marginRight="-3px";break;case 2:a.top+=3,a.bottom+=3,this._hoverContainer.style.paddingTop="3px",this._hoverContainer.style.marginTop="-3px";break;case 3:a.top-=3,a.bottom-=3,this._hoverContainer.style.paddingBottom="3px",this._hoverContainer.style.marginBottom="-3px"}a.center.x=a.left+r/2,a.center.y=a.top+o/2}this.computeXCordinate(a),this.computeYCordinate(a),this._hoverPointer&&(this._hoverPointer.classList.remove("top"),this._hoverPointer.classList.remove("left"),this._hoverPointer.classList.remove("right"),this._hoverPointer.classList.remove("bottom"),this.setHoverPointerPosition(a)),this._hover.onContentsChanged()}computeXCordinate(e){const t=this._hover.containerDomNode.clientWidth+2;void 0!==this._target.x?this._x=this._target.x:1===this._hoverPosition?this._x=e.right:0===this._hoverPosition?this._x=e.left-t:(this._hoverPointer?this._x=e.center.x-this._hover.containerDomNode.clientWidth/2:this._x=e.left,this._x+t>=this._targetDocumentElement.clientWidth&&(this._hover.containerDomNode.classList.add("right-aligned"),this._x=Math.max(this._targetDocumentElement.clientWidth-t-2,this._targetDocumentElement.clientLeft))),this._xthis._targetWindow.innerHeight&&(this._y=e.bottom)}adjustHorizontalHoverPosition(e){if(void 0!==this._target.x)return;const t=this._hoverPointer?3:0;if(this._forcePosition){const i=t+2;1===this._hoverPosition?this._hover.containerDomNode.style.maxWidth=this._targetDocumentElement.clientWidth-e.right-i+"px":0===this._hoverPosition&&(this._hover.containerDomNode.style.maxWidth=e.left-i+"px")}else if(1===this._hoverPosition){if(this._targetDocumentElement.clientWidth-e.right=this._hover.containerDomNode.clientWidth+t?this._hoverPosition=0:this._hoverPosition=2}}else if(0===this._hoverPosition){if(e.left=this._hover.containerDomNode.clientWidth+t?this._hoverPosition=1:this._hoverPosition=2}e.left-this._hover.containerDomNode.clientWidth-t<=this._targetDocumentElement.clientLeft&&(this._hoverPosition=1)}}adjustVerticalHoverPosition(e){if(void 0!==this._target.y||this._forcePosition)return;const t=this._hoverPointer?3:0;3===this._hoverPosition?e.top-this._hover.containerDomNode.clientHeight-t<0&&(this._hoverPosition=2):2===this._hoverPosition&&e.bottom+this._hover.containerDomNode.clientHeight+t>this._targetWindow.innerHeight&&(this._hoverPosition=3)}adjustHoverMaxHeight(e){let t=this._targetWindow.innerHeight/2;if(this._forcePosition){const i=2+(this._hoverPointer?3:0);3===this._hoverPosition?t=Math.min(t,e.top-i):2===this._hoverPosition&&(t=Math.min(t,this._targetWindow.innerHeight-e.bottom-i))}if(this._hover.containerDomNode.style.maxHeight=`${t}px`,this._hover.contentsDomNode.clientHeighte.height?this._hoverPointer.style.top=e.center.y-(this._y-t)-3+"px":this._hoverPointer.style.top=Math.round(t/2)-3+"px";break}case 3:case 2:{this._hoverPointer.classList.add(3===this._hoverPosition?"bottom":"top");const t=this._hover.containerDomNode.clientWidth;let i=Math.round(t/2)-3;const s=this._x+i;(se.right)&&(i=e.center.x-this._x-3),this._hoverPointer.style.left=`${i}px`;break}}}focus(){this._hover.containerDomNode.focus()}dispose(){this._isDisposed||(this._onDispose.fire(),this._hoverContainer.remove(),this._messageListeners.dispose(),this._target.dispose(),super.dispose()),this._isDisposed=!0}};Ye=Ge([je(1,De.b),je(2,Me.pG),je(3,Ue.C),je(4,ae._Y),je(5,Ve.j)],Ye);class qe extends Fe.x{get onMouseOut(){return this._onMouseOut.event}get isMouseIn(){return this._isMouseIn}constructor(e){super(),this._elements=e,this._isMouseIn=!0,this._onMouseOut=this._register(new Q.vl),this._elements.forEach((e=>this.onmouseover(e,(()=>this._onTargetMouseOver(e))))),this._elements.forEach((e=>this.onmouseleave(e,(()=>this._onTargetMouseLeave(e)))))}_onTargetMouseOver(e){this._isMouseIn=!0,this._clearEvaluateMouseStateTimeout(e)}_onTargetMouseLeave(e){this._isMouseIn=!1,this._evaluateMouseState(e)}_evaluateMouseState(e){this._clearEvaluateMouseStateTimeout(e),this._mouseTimeout=U.zk(e).setTimeout((()=>this._fireIfMouseOutside()),0)}_clearEvaluateMouseStateTimeout(e){this._mouseTimeout&&(U.zk(e).clearTimeout(this._mouseTimeout),this._mouseTimeout=void 0)}_fireIfMouseOutside(){this._isMouseIn||this._onMouseOut.fire()}}class $e{constructor(e){this._element=e,this.targetElements=[this._element]}dispose(){}}var Qe,Xe=i(72962),Ze=i(55089),Je=i(92719);function et(e,t,i){const s=i.mode===Qe.ALIGN?i.offset:i.offset+i.size,n=i.mode===Qe.ALIGN?i.offset+i.size:i.offset;return 0===i.position?t<=e-s?s:t<=n?n-t:Math.max(e-t,0):t<=n?n-t:t<=e-s?s:0}!function(e){e[e.AVOID=0]="AVOID",e[e.ALIGN=1]="ALIGN"}(Qe||(Qe={}));class tt extends c.jG{static{this.BUBBLE_UP_EVENTS=["click","keydown","focus","blur"]}static{this.BUBBLE_DOWN_EVENTS=["click"]}constructor(e,t){super(),this.container=null,this.useFixedPosition=!1,this.useShadowDOM=!1,this.delegate=null,this.toDisposeOnClean=c.jG.None,this.toDisposeOnSetContainer=c.jG.None,this.shadowRoot=null,this.shadowRootHostElement=null,this.view=U.$(".context-view"),U.jD(this.view),this.setContainer(e,t),this._register((0,c.s)((()=>this.setContainer(null,1))))}setContainer(e,t){this.useFixedPosition=1!==t;const i=this.useShadowDOM;if(this.useShadowDOM=3===t,(e!==this.container||i!==this.useShadowDOM)&&(this.container&&(this.toDisposeOnSetContainer.dispose(),this.view.remove(),this.shadowRoot&&(this.shadowRoot=null,this.shadowRootHostElement?.remove(),this.shadowRootHostElement=null),this.container=null),e)){if(this.container=e,this.useShadowDOM){this.shadowRootHostElement=U.$(".shadow-root-host"),this.container.appendChild(this.shadowRootHostElement),this.shadowRoot=this.shadowRootHostElement.attachShadow({mode:"open"});const e=document.createElement("style");e.textContent=it,this.shadowRoot.appendChild(e),this.shadowRoot.appendChild(this.view),this.shadowRoot.appendChild(U.$("slot"))}else this.container.appendChild(this.view);const t=new c.Cm;tt.BUBBLE_UP_EVENTS.forEach((e=>{t.add(U.b2(this.container,e,(e=>{this.onDOMEvent(e,!1)})))})),tt.BUBBLE_DOWN_EVENTS.forEach((e=>{t.add(U.b2(this.container,e,(e=>{this.onDOMEvent(e,!0)}),!0))})),this.toDisposeOnSetContainer=t}}show(e){this.isVisible()&&this.hide(),U.w_(this.view),this.view.className="context-view monaco-component",this.view.style.top="0px",this.view.style.left="0px",this.view.style.zIndex=`${2575+(e.layer??0)}`,this.view.style.position=this.useFixedPosition?"fixed":"absolute",U.WU(this.view),this.toDisposeOnClean=e.render(this.view)||c.jG.None,this.delegate=e,this.doLayout(),this.delegate.focus?.()}getViewElement(){return this.view}layout(){this.isVisible()&&(!1!==this.delegate.canRelayout||We.un&&Ze.e.pointerEvents?(this.delegate?.layout?.(),this.doLayout()):this.hide())}doLayout(){if(!this.isVisible())return;const e=this.delegate.getAnchor();let t;if(U.sb(e)){const i=U.BK(e),s=U.mU(e);t={top:i.top*s,left:i.left*s,width:i.width*s,height:i.height*s}}else t=function(e){const t=e;return!!t&&"number"===typeof t.x&&"number"===typeof t.y}(e)?{top:e.y,left:e.x,width:e.width||1,height:e.height||2}:{top:e.posy,left:e.posx,width:2,height:2};const i=U.Tr(this.view),s=U.OK(this.view),n=this.delegate.anchorPosition||0,r=this.delegate.anchorAlignment||0,o=this.delegate.anchorAxisAlignment||0;let a,c;const l=U.fz();if(0===o){const e={offset:t.top-l.pageYOffset,size:t.height,position:0===n?0:1},o={offset:t.left,size:t.width,position:0===r?0:1,mode:Qe.ALIGN};a=et(l.innerHeight,s,e)+l.pageYOffset,Je.Q.intersects({start:a,end:a+s},{start:e.offset,end:e.offset+e.size})&&(o.mode=Qe.AVOID),c=et(l.innerWidth,i,o)}else{const e={offset:t.left,size:t.width,position:0===r?0:1},o={offset:t.top,size:t.height,position:0===n?0:1,mode:Qe.ALIGN};c=et(l.innerWidth,i,e),Je.Q.intersects({start:c,end:c+i},{start:e.offset,end:e.offset+e.size})&&(o.mode=Qe.AVOID),a=et(l.innerHeight,s,o)+l.pageYOffset}this.view.classList.remove("top","bottom","left","right"),this.view.classList.add(0===n?"bottom":"top"),this.view.classList.add(0===r?"left":"right"),this.view.classList.toggle("fixed",this.useFixedPosition);const h=U.BK(this.container);this.view.style.top=a-(this.useFixedPosition?U.BK(this.view).top:h.top)+"px",this.view.style.left=c-(this.useFixedPosition?U.BK(this.view).left:h.left)+"px",this.view.style.width="initial"}hide(e){const t=this.delegate;this.delegate=null,t?.onHide&&t.onHide(e),this.toDisposeOnClean.dispose(),U.jD(this.view)}isVisible(){return!!this.delegate}onDOMEvent(e,t){this.delegate&&(this.delegate.onDOMEvent?this.delegate.onDOMEvent(e,U.zk(e).document.activeElement):t&&!U.QX(e.target,this.container)&&this.hide())}dispose(){this.hide(),super.dispose()}}const it='\n\t:host {\n\t\tall: initial; /* 1st rule so subsequent properties are reset. */\n\t}\n\n\t.codicon[class*=\'codicon-\'] {\n\t\tfont: normal normal normal 16px/1 codicon;\n\t\tdisplay: inline-block;\n\t\ttext-decoration: none;\n\t\ttext-rendering: auto;\n\t\ttext-align: center;\n\t\t-webkit-font-smoothing: antialiased;\n\t\t-moz-osx-font-smoothing: grayscale;\n\t\tuser-select: none;\n\t\t-webkit-user-select: none;\n\t\t-ms-user-select: none;\n\t}\n\n\t:host {\n\t\tfont-family: -apple-system, BlinkMacSystemFont, "Segoe WPC", "Segoe UI", "HelveticaNeue-Light", system-ui, "Ubuntu", "Droid Sans", sans-serif;\n\t}\n\n\t:host-context(.mac) { font-family: -apple-system, BlinkMacSystemFont, sans-serif; }\n\t:host-context(.mac:lang(zh-Hans)) { font-family: -apple-system, BlinkMacSystemFont, "PingFang SC", "Hiragino Sans GB", sans-serif; }\n\t:host-context(.mac:lang(zh-Hant)) { font-family: -apple-system, BlinkMacSystemFont, "PingFang TC", sans-serif; }\n\t:host-context(.mac:lang(ja)) { font-family: -apple-system, BlinkMacSystemFont, "Hiragino Kaku Gothic Pro", sans-serif; }\n\t:host-context(.mac:lang(ko)) { font-family: -apple-system, BlinkMacSystemFont, "Nanum Gothic", "Apple SD Gothic Neo", "AppleGothic", sans-serif; }\n\n\t:host-context(.windows) { font-family: "Segoe WPC", "Segoe UI", sans-serif; }\n\t:host-context(.windows:lang(zh-Hans)) { font-family: "Segoe WPC", "Segoe UI", "Microsoft YaHei", sans-serif; }\n\t:host-context(.windows:lang(zh-Hant)) { font-family: "Segoe WPC", "Segoe UI", "Microsoft Jhenghei", sans-serif; }\n\t:host-context(.windows:lang(ja)) { font-family: "Segoe WPC", "Segoe UI", "Yu Gothic UI", "Meiryo UI", sans-serif; }\n\t:host-context(.windows:lang(ko)) { font-family: "Segoe WPC", "Segoe UI", "Malgun Gothic", "Dotom", sans-serif; }\n\n\t:host-context(.linux) { font-family: system-ui, "Ubuntu", "Droid Sans", sans-serif; }\n\t:host-context(.linux:lang(zh-Hans)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans SC", "Source Han Sans CN", "Source Han Sans", sans-serif; }\n\t:host-context(.linux:lang(zh-Hant)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans TC", "Source Han Sans TW", "Source Han Sans", sans-serif; }\n\t:host-context(.linux:lang(ja)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans J", "Source Han Sans JP", "Source Han Sans", sans-serif; }\n\t:host-context(.linux:lang(ko)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans K", "Source Han Sans JR", "Source Han Sans", "UnDotum", "FBaekmuk Gulim", sans-serif; }\n';var st=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},nt=function(e,t){return function(i,s){t(i,s,e)}};let rt=class extends c.jG{constructor(e){super(),this.layoutService=e,this.contextView=this._register(new tt(this.layoutService.mainContainer,1)),this.layout(),this._register(e.onDidLayoutContainer((()=>this.layout())))}showContextView(e,t,i){let s;s=t?t===this.layoutService.getContainer((0,U.zk)(t))?1:i?3:2:1,this.contextView.setContainer(t??this.layoutService.activeContainer,s),this.contextView.show(e);const n={close:()=>{this.openContextView===n&&this.hideContextView()}};return this.openContextView=n,n}layout(){this.contextView.layout()}hideContextView(e){this.contextView.hide(e),this.openContextView=void 0}};rt=st([nt(0,ce)],rt);class ot extends rt{getContextViewElement(){return this.contextView.getViewElement()}}var at=i(18447),ct=i(631);class lt{constructor(e,t,i){this.hoverDelegate=e,this.target=t,this.fadeInAnimation=i}async update(e,t,i){if(this._cancellationTokenSource&&(this._cancellationTokenSource.dispose(!0),this._cancellationTokenSource=void 0),this.isDisposed)return;let s;if(void 0===e||(0,ct.Kg)(e)||(0,U.sb)(e))s=e;else if((0,ct.Tn)(e.markdown)){this._hoverWidget||this.show((0,b.kg)("iconLabel.loading","Loading..."),t,i),this._cancellationTokenSource=new at.Qi;const n=this._cancellationTokenSource.token;if(s=await e.markdown(n),void 0===s&&(s=e.markdownNotSupportedFallback),this.isDisposed||n.isCancellationRequested)return}else s=e.markdown??e.markdownNotSupportedFallback;this.show(s,t,i)}show(e,t,i){const s=this._hoverWidget;if(this.hasContent(e)){const n={content:e,target:this.target,actions:i?.actions,linkHandler:i?.linkHandler,trapFocus:i?.trapFocus,appearance:{showPointer:"element"===this.hoverDelegate.placement,skipFadeInAnimation:!this.fadeInAnimation||!!s,showHoverHint:i?.appearance?.showHoverHint},position:{hoverPosition:2}};this._hoverWidget=this.hoverDelegate.showHover(n,t)}s?.dispose()}hasContent(e){return!!e&&(!(0,Be.VS)(e)||!!e.value)}get isDisposed(){return this._hoverWidget?.isDisposed}dispose(){this._hoverWidget?.dispose(),this._cancellationTokenSource?.dispose(!0),this._cancellationTokenSource=void 0}}var ht=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},dt=function(e,t){return function(i,s){t(i,s,e)}};let ut=class extends c.jG{constructor(e,t,i,s,n){super(),this._instantiationService=e,this._keybindingService=i,this._layoutService=s,this._accessibilityService=n,this._managedHovers=new Map,t.onDidShowContextMenu((()=>this.hideHover())),this._contextViewHandler=this._register(new rt(this._layoutService))}showHover(e,t,i){if(gt(this._currentHoverOptions)===gt(e))return;if(this._currentHover&&this._currentHoverOptions?.persistence?.sticky)return;this._currentHoverOptions=e,this._lastHoverOptions=e;const s=e.trapFocus||this._accessibilityService.isScreenReaderOptimized(),n=(0,U.bq)();i||(s&&n?n.classList.contains("monaco-hover")||(this._lastFocusedElementBeforeOpen=n):this._lastFocusedElementBeforeOpen=void 0);const r=new c.Cm,o=this._instantiationService.createInstance(Ye,e);if(e.persistence?.sticky&&(o.isLocked=!0),o.onDispose((()=>{this._currentHover?.domNode&&(0,U.nR)(this._currentHover.domNode)&&this._lastFocusedElementBeforeOpen?.focus(),this._currentHoverOptions===e&&(this._currentHoverOptions=void 0),r.dispose()}),void 0,r),!e.container){const t=(0,U.sb)(e.target)?e.target:e.target.targetElements[0];e.container=this._layoutService.getContainer((0,U.zk)(t))}if(this._contextViewHandler.showContextView(new pt(o,t),e.container),o.onRequestLayout((()=>this._contextViewHandler.layout()),void 0,r),e.persistence?.sticky)r.add((0,U.ko)((0,U.zk)(e.container).document,U.Bx.MOUSE_DOWN,(e=>{(0,U.QX)(e.target,o.domNode)||this.doHideHover()})));else{if("targetElements"in e.target)for(const i of e.target.targetElements)r.add((0,U.ko)(i,U.Bx.CLICK,(()=>this.hideHover())));else r.add((0,U.ko)(e.target,U.Bx.CLICK,(()=>this.hideHover())));const t=(0,U.bq)();if(t){const i=(0,U.zk)(t).document;r.add((0,U.ko)(t,U.Bx.KEY_DOWN,(t=>this._keyDown(t,o,!!e.persistence?.hideOnKeyDown)))),r.add((0,U.ko)(i,U.Bx.KEY_DOWN,(t=>this._keyDown(t,o,!!e.persistence?.hideOnKeyDown)))),r.add((0,U.ko)(t,U.Bx.KEY_UP,(e=>this._keyUp(e,o)))),r.add((0,U.ko)(i,U.Bx.KEY_UP,(e=>this._keyUp(e,o))))}}if("IntersectionObserver"in a.G){const t=new IntersectionObserver((e=>this._intersectionChange(e,o)),{threshold:0}),i="targetElements"in e.target?e.target.targetElements[0]:e.target;t.observe(i),r.add((0,c.s)((()=>t.disconnect())))}return this._currentHover=o,o}hideHover(){!this._currentHover?.isLocked&&this._currentHoverOptions&&this.doHideHover()}doHideHover(){this._currentHover=void 0,this._currentHoverOptions=void 0,this._contextViewHandler.hideContextView()}_intersectionChange(e,t){e[e.length-1].isIntersecting||t.dispose()}showAndFocusLastHover(){this._lastHoverOptions&&this.showHover(this._lastHoverOptions,!0,!0)}_keyDown(e,t,i){if("Alt"===e.key)return void(t.isLocked=!0);const s=new Xe.Z(e);this._keybindingService.resolveKeyboardEvent(s).getSingleModifierDispatchChords().some((e=>!!e))||0!==this._keybindingService.softDispatch(s,s.target).kind||!i||this._currentHoverOptions?.trapFocus&&"Tab"===e.key||(this.hideHover(),this._lastFocusedElementBeforeOpen?.focus())}_keyUp(e,t){"Alt"===e.key&&(t.isLocked=!1,t.isMouseIn||(this.hideHover(),this._lastFocusedElementBeforeOpen?.focus()))}setupManagedHover(e,t,i,s){let n,r;t.setAttribute("custom-hover","true"),""!==t.title&&(console.warn("HTML element already has a title attribute, which will conflict with the custom hover. Please remove the title attribute."),console.trace("Stack trace:",t.title),t.title="");const o=(t,i)=>{const s=void 0!==r;t&&(r?.dispose(),r=void 0),i&&(n?.dispose(),n=void 0),s&&(e.onDidHideHover?.(),r=void 0)},a=(n,o,a,c)=>new m.pc((async()=>{r&&!r.isDisposed||(r=new lt(e,a||t,n>0),await r.update("function"===typeof i?i():i,o,{...s,trapFocus:c}))}),n);let l=!1;const h=(0,U.ko)(t,U.Bx.MOUSE_DOWN,(()=>{l=!0,o(!0,!0)}),!0),d=(0,U.ko)(t,U.Bx.MOUSE_UP,(()=>{l=!1}),!0),u=(0,U.ko)(t,U.Bx.MOUSE_LEAVE,(e=>{l=!1,o(!1,e.fromElement===t)}),!0),g=(0,U.ko)(t,U.Bx.MOUSE_OVER,(i=>{if(n)return;const s=new c.Cm,r={targetElements:[t],dispose:()=>{}};if(void 0===e.placement||"mouse"===e.placement){const e=e=>{r.x=e.x+10,(0,U.sb)(e.target)&&mt(e.target,t)!==t&&o(!0,!0)};s.add((0,U.ko)(t,U.Bx.MOUSE_MOVE,e,!0))}n=s,(0,U.sb)(i.target)&&mt(i.target,t)!==t||s.add(a(e.delay,!1,r))}),!0),p=()=>{if(l||n)return;const i={targetElements:[t],dispose:()=>{}},s=new c.Cm;s.add((0,U.ko)(t,U.Bx.BLUR,(()=>o(!0,!0)),!0)),s.add(a(e.delay,!1,i)),n=s};let f;const _=t.tagName.toLowerCase();"input"!==_&&"textarea"!==_&&(f=(0,U.ko)(t,U.Bx.FOCUS,p,!0));const v={show:e=>{o(!1,!0),a(0,e,void 0,e)},hide:()=>{o(!0,!0)},update:async(e,t)=>{i=e,await(r?.update(i,void 0,t))},dispose:()=>{this._managedHovers.delete(t),g.dispose(),u.dispose(),h.dispose(),d.dispose(),f?.dispose(),o(!0,!0)}};return this._managedHovers.set(t,v),v}showManagedHover(e){const t=this._managedHovers.get(e);t&&t.show(!0)}dispose(){this._managedHovers.forEach((e=>e.dispose())),super.dispose()}};function gt(e){if(void 0!==e)return e?.id??e}ut=ht([dt(0,ae._Y),dt(1,Oe.Z),dt(2,De.b),dt(3,ce),dt(4,Ve.j)],ut);class pt{get anchorPosition(){return this._hover.anchor}constructor(e,t=!1){this._hover=e,this._focus=t,this.layer=1}render(e){return this._hover.render(e),this._focus&&this._hover.focus(),this._hover}getAnchor(){return{x:this._hover.x,y:this._hover.y}}layout(){this._hover.layout()}}function mt(e,t){for(t=t??(0,U.zk)(e).document.body;!e.hasAttribute("custom-hover")&&e!==t;)e=e.parentElement;return e}(0,se.v)(Ie.TN,ut,1),(0,Z.zy)(((e,t)=>{const i=e.getColor(Ne.oZ8);i&&(t.addRule(`.monaco-workbench .workbench-hover .hover-row:not(:first-child):not(:empty) { border-top: 1px solid ${i.transparent(.5)}; }`),t.addRule(`.monaco-workbench .workbench-hover hr { border-top: 1px solid ${i.transparent(.5)}; }`))}));var ft=i(42539),_t=i(80537),vt=i(94371),Ct=i(7085),Et=i(83069),bt=i(18938),St=i(50091),yt=i(74320),wt=i(1646),Rt=i(46359);function Lt(e){return Object.isFrozen(e)?e:p.ol(e)}class Tt{static createEmptyModel(e){return new Tt({},[],[],void 0,e)}constructor(e,t,i,s,n){this._contents=e,this._keys=t,this._overrides=i,this.raw=s,this.logService=n,this.overrideConfigurations=new Map}get rawConfiguration(){if(!this._rawConfiguration)if(this.raw?.length){const e=this.raw.map((e=>{if(e instanceof Tt)return e;const t=new xt("",this.logService);return t.parseRaw(e),t.configurationModel}));this._rawConfiguration=e.reduce(((e,t)=>t===e?t:e.merge(t)),e[0])}else this._rawConfiguration=this;return this._rawConfiguration}get contents(){return this._contents}get overrides(){return this._overrides}get keys(){return this._keys}isEmpty(){return 0===this._keys.length&&0===Object.keys(this._contents).length&&0===this._overrides.length}getValue(e){return e?(0,Me.gD)(this.contents,e):this.contents}inspect(e,t){const i=this;return{get value(){return Lt(i.rawConfiguration.getValue(e))},get override(){return t?Lt(i.rawConfiguration.getOverrideValue(e,t)):void 0},get merged(){return Lt(t?i.rawConfiguration.override(t).getValue(e):i.rawConfiguration.getValue(e))},get overrides(){const t=[];for(const{contents:s,identifiers:n,keys:r}of i.rawConfiguration.overrides){const o=new Tt(s,r,[],void 0,i.logService).getValue(e);void 0!==o&&t.push({identifiers:n,value:o})}return t.length?Lt(t):void 0}}}getOverrideValue(e,t){const i=this.getContentsForOverrideIdentifer(t);return i?e?(0,Me.gD)(i,e):i:void 0}override(e){let t=this.overrideConfigurations.get(e);return t||(t=this.createOverrideConfigurationModel(e),this.overrideConfigurations.set(e,t)),t}merge(...e){const t=p.Go(this.contents),i=p.Go(this.overrides),s=[...this.keys],n=this.raw?.length?[...this.raw]:[this];for(const r of e)if(n.push(...r.raw?.length?r.raw:[r]),!r.isEmpty()){this.mergeContents(t,r.contents);for(const e of r.overrides){const[t]=i.filter((t=>E.aI(t.identifiers,e.identifiers)));t?(this.mergeContents(t.contents,e.contents),t.keys.push(...e.keys),t.keys=E.dM(t.keys)):i.push(p.Go(e))}for(const e of r.keys)-1===s.indexOf(e)&&s.push(e)}return new Tt(t,s,i,n.every((e=>e instanceof Tt))?void 0:n,this.logService)}createOverrideConfigurationModel(e){const t=this.getContentsForOverrideIdentifer(e);if(!t||"object"!==typeof t||!Object.keys(t).length)return this;const i={};for(const s of E.dM([...Object.keys(this.contents),...Object.keys(t)])){let e=this.contents[s];const n=t[s];n&&("object"===typeof e&&"object"===typeof n?(e=p.Go(e),this.mergeContents(e,n)):e=n),i[s]=e}return new Tt(i,this.keys,this.overrides,void 0,this.logService)}mergeContents(e,t){for(const i of Object.keys(t))i in e&&ct.Gv(e[i])&&ct.Gv(t[i])?this.mergeContents(e[i],t[i]):e[i]=p.Go(t[i])}getContentsForOverrideIdentifer(e){let t=null,i=null;const s=e=>{e&&(i?this.mergeContents(i,e):i=p.Go(e))};for(const n of this.overrides)1===n.identifiers.length&&n.identifiers[0]===e?t=n.contents:n.identifiers.includes(e)&&s(n.contents);return s(t),i}toJSON(){return{contents:this.contents,overrides:this.overrides,keys:this.keys}}setValue(e,t){this.updateValue(e,t,!1)}removeValue(e){const t=this.keys.indexOf(e);-1!==t&&(this.keys.splice(t,1),(0,Me.iB)(this.contents,e),wt.rC.test(e)&&this.overrides.splice(this.overrides.findIndex((t=>E.aI(t.identifiers,(0,wt.Gv)(e)))),1))}updateValue(e,t,i){if((0,Me.kW)(this.contents,e,t,(e=>this.logService.error(e))),(i=i||-1===this.keys.indexOf(e))&&this.keys.push(e),wt.rC.test(e)){const t=(0,wt.Gv)(e),i={identifiers:t,keys:Object.keys(this.contents[e]),contents:(0,Me.ad)(this.contents[e],(e=>this.logService.error(e)))},s=this.overrides.findIndex((e=>E.aI(e.identifiers,t)));-1!==s?this.overrides[s]=i:this.overrides.push(i)}}}class xt{constructor(e,t){this._name=e,this.logService=t,this._raw=null,this._configurationModel=null,this._restrictedConfigurations=[]}get configurationModel(){return this._configurationModel||Tt.createEmptyModel(this.logService)}parseRaw(e,t){this._raw=e;const{contents:i,keys:s,overrides:n,restricted:r,hasExcludedProperties:o}=this.doParseRaw(e,t);this._configurationModel=new Tt(i,s,n,o?[e]:void 0,this.logService),this._restrictedConfigurations=r||[]}doParseRaw(e,t){const i=Rt.O.as(wt.Fd.Configuration).getConfigurationProperties(),s=this.filter(e,i,!0,t);e=s.raw;return{contents:(0,Me.ad)(e,(e=>this.logService.error(`Conflict in settings file ${this._name}: ${e}`))),keys:Object.keys(e),overrides:this.toOverrides(e,(e=>this.logService.error(`Conflict in settings file ${this._name}: ${e}`))),restricted:s.restricted,hasExcludedProperties:s.hasExcludedProperties}}filter(e,t,i,s){let n=!1;if(!s?.scopes&&!s?.skipRestricted&&!s?.exclude?.length)return{raw:e,restricted:[],hasExcludedProperties:n};const r={},o=[];for(const a in e)if(wt.rC.test(a)&&i){const i=this.filter(e[a],t,!1,s);r[a]=i.raw,n=n||i.hasExcludedProperties,o.push(...i.restricted)}else{const i=t[a],c=i?"undefined"!==typeof i.scope?i.scope:3:void 0;i?.restricted&&o.push(a),s.exclude?.includes(a)||!s.include?.includes(a)&&(void 0!==c&&void 0!==s.scopes&&!s.scopes.includes(c)||s.skipRestricted&&i?.restricted)?n=!0:r[a]=e[a]}return{raw:r,restricted:o,hasExcludedProperties:n}}toOverrides(e,t){const i=[];for(const s of Object.keys(e))if(wt.rC.test(s)){const n={};for(const t in e[s])n[t]=e[s][t];i.push({identifiers:(0,wt.Gv)(s),keys:Object.keys(n),contents:(0,Me.ad)(n,t)})}return i}}class kt{constructor(e,t,i,s,n,r,o,a,c,l,h,d,u){this.key=e,this.overrides=t,this._value=i,this.overrideIdentifiers=s,this.defaultConfiguration=n,this.policyConfiguration=r,this.applicationConfiguration=o,this.userConfiguration=a,this.localUserConfiguration=c,this.remoteUserConfiguration=l,this.workspaceConfiguration=h,this.folderConfigurationModel=d,this.memoryConfigurationModel=u}toInspectValue(e){return void 0!==e?.value||void 0!==e?.override||void 0!==e?.overrides?e:void 0}get userInspectValue(){return this._userInspectValue||(this._userInspectValue=this.userConfiguration.inspect(this.key,this.overrides.overrideIdentifier)),this._userInspectValue}get user(){return this.toInspectValue(this.userInspectValue)}}class At{constructor(e,t,i,s,n,r,o,a,c,l){this._defaultConfiguration=e,this._policyConfiguration=t,this._applicationConfiguration=i,this._localUserConfiguration=s,this._remoteUserConfiguration=n,this._workspaceConfiguration=r,this._folderConfigurations=o,this._memoryConfiguration=a,this._memoryConfigurationByResource=c,this.logService=l,this._workspaceConsolidatedConfiguration=null,this._foldersConsolidatedConfigurations=new yt.fT,this._userConfiguration=null}getValue(e,t,i){return this.getConsolidatedConfigurationModel(e,t,i).getValue(e)}updateValue(e,t,i={}){let s;i.resource?(s=this._memoryConfigurationByResource.get(i.resource),s||(s=Tt.createEmptyModel(this.logService),this._memoryConfigurationByResource.set(i.resource,s))):s=this._memoryConfiguration,void 0===t?s.removeValue(e):s.setValue(e,t),i.resource||(this._workspaceConsolidatedConfiguration=null)}inspect(e,t,i){const s=this.getConsolidatedConfigurationModel(e,t,i),n=this.getFolderConfigurationModelForResource(t.resource,i),r=t.resource&&this._memoryConfigurationByResource.get(t.resource)||this._memoryConfiguration,o=new Set;for(const a of s.overrides)for(const t of a.identifiers)void 0!==s.getOverrideValue(e,t)&&o.add(t);return new kt(e,t,s.getValue(e),o.size?[...o]:void 0,this._defaultConfiguration,this._policyConfiguration.isEmpty()?void 0:this._policyConfiguration,this.applicationConfiguration.isEmpty()?void 0:this.applicationConfiguration,this.userConfiguration,this.localUserConfiguration,this.remoteUserConfiguration,i?this._workspaceConfiguration:void 0,n||void 0,r)}get applicationConfiguration(){return this._applicationConfiguration}get userConfiguration(){return this._userConfiguration||(this._userConfiguration=this._remoteUserConfiguration.isEmpty()?this._localUserConfiguration:this._localUserConfiguration.merge(this._remoteUserConfiguration)),this._userConfiguration}get localUserConfiguration(){return this._localUserConfiguration}get remoteUserConfiguration(){return this._remoteUserConfiguration}getConsolidatedConfigurationModel(e,t,i){let s=this.getConsolidatedConfigurationModelForResource(t,i);return t.overrideIdentifier&&(s=s.override(t.overrideIdentifier)),this._policyConfiguration.isEmpty()||void 0===this._policyConfiguration.getValue(e)||(s=s.merge(this._policyConfiguration)),s}getConsolidatedConfigurationModelForResource({resource:e},t){let i=this.getWorkspaceConsolidatedConfiguration();if(t&&e){const s=t.getFolder(e);s&&(i=this.getFolderConsolidatedConfiguration(s.uri)||i);const n=this._memoryConfigurationByResource.get(e);n&&(i=i.merge(n))}return i}getWorkspaceConsolidatedConfiguration(){return this._workspaceConsolidatedConfiguration||(this._workspaceConsolidatedConfiguration=this._defaultConfiguration.merge(this.applicationConfiguration,this.userConfiguration,this._workspaceConfiguration,this._memoryConfiguration)),this._workspaceConsolidatedConfiguration}getFolderConsolidatedConfiguration(e){let t=this._foldersConsolidatedConfigurations.get(e);if(!t){const i=this.getWorkspaceConsolidatedConfiguration(),s=this._folderConfigurations.get(e);s?(t=i.merge(s),this._foldersConsolidatedConfigurations.set(e,t)):t=i}return t}getFolderConfigurationModelForResource(e,t){if(t&&e){const i=t.getFolder(e);if(i)return this._folderConfigurations.get(i.uri)}}toData(){return{defaults:{contents:this._defaultConfiguration.contents,overrides:this._defaultConfiguration.overrides,keys:this._defaultConfiguration.keys},policy:{contents:this._policyConfiguration.contents,overrides:this._policyConfiguration.overrides,keys:this._policyConfiguration.keys},application:{contents:this.applicationConfiguration.contents,overrides:this.applicationConfiguration.overrides,keys:this.applicationConfiguration.keys},user:{contents:this.userConfiguration.contents,overrides:this.userConfiguration.overrides,keys:this.userConfiguration.keys},workspace:{contents:this._workspaceConfiguration.contents,overrides:this._workspaceConfiguration.overrides,keys:this._workspaceConfiguration.keys},folders:[...this._folderConfigurations.keys()].reduce(((e,t)=>{const{contents:i,overrides:s,keys:n}=this._folderConfigurations.get(t);return e.push([t,{contents:i,overrides:s,keys:n}]),e}),[])}}static parse(e,t){const i=this.parseConfigurationModel(e.defaults,t),s=this.parseConfigurationModel(e.policy,t),n=this.parseConfigurationModel(e.application,t),r=this.parseConfigurationModel(e.user,t),o=this.parseConfigurationModel(e.workspace,t),a=e.folders.reduce(((e,i)=>(e.set(h.r.revive(i[0]),this.parseConfigurationModel(i[1],t)),e)),new yt.fT);return new At(i,s,n,r,Tt.createEmptyModel(t),o,a,Tt.createEmptyModel(t),new yt.fT,t)}static parseConfigurationModel(e,t){return new Tt(e.contents,e.keys,e.overrides,void 0,t)}}class Nt{constructor(e,t,i,s,n){this.change=e,this.previous=t,this.currentConfiguraiton=i,this.currentWorkspace=s,this.logService=n,this._marker="\n",this._markerCode1=this._marker.charCodeAt(0),this._markerCode2=".".charCodeAt(0),this.affectedKeys=new Set,this._previousConfiguration=void 0;for(const r of e.keys)this.affectedKeys.add(r);for(const[,r]of e.overrides)for(const e of r)this.affectedKeys.add(e);this._affectsConfigStr=this._marker;for(const r of this.affectedKeys)this._affectsConfigStr+=r+this._marker}get previousConfiguration(){return!this._previousConfiguration&&this.previous&&(this._previousConfiguration=At.parse(this.previous.data,this.logService)),this._previousConfiguration}affectsConfiguration(e,t){const i=this._marker+e,s=this._affectsConfigStr.indexOf(i);if(s<0)return!1;const n=s+i.length;if(n>=this._affectsConfigStr.length)return!1;const r=this._affectsConfigStr.charCodeAt(n);if(r!==this._markerCode1&&r!==this._markerCode2)return!1;if(t){const i=this.previousConfiguration?this.previousConfiguration.getValue(e,t,this.previous?.workspace):void 0,s=this.currentConfiguraiton.getValue(e,t,this.currentWorkspace);return!p.aI(i,s)}return!0}}var It=i(2299);const Ot={kind:0},Dt={kind:1};class Mt{constructor(e,t,i){this._log=i,this._defaultKeybindings=e,this._defaultBoundCommands=new Map;for(const s of e){const e=s.command;e&&"-"!==e.charAt(0)&&this._defaultBoundCommands.set(e,!0)}this._map=new Map,this._lookupMap=new Map,this._keybindings=Mt.handleRemovals([].concat(e).concat(t));for(let s=0,n=this._keybindings.length;s=0;s--){const e=i[s];if(e.command===t.command)continue;let n=!0;for(let i=1;i=0;s--){const e=i[s];if(t.contextMatchesRules(e.when))return e}return i[i.length-1]}resolve(e,t,i){const s=[...t,i];this._log(`| Resolving ${s}`);const n=this._map.get(s[0]);if(void 0===n)return this._log("\\ No keybinding entries."),Ot;let r=null;if(s.length<2)r=n;else{r=[];for(let e=0,t=n.length;et.chords.length)continue;let i=!0;for(let e=1;e=0;i--){const s=t[i];if(Mt._contextMatchesRules(e,s.when))return s}return null}static _contextMatchesRules(e,t){return!t||t.evaluate(e)}}function Pt(e){return e?`${e.serialize()}`:"no when condition"}function Ft(e){return e.extensionId?e.isBuiltinExtension?`built-in extension ${e.extensionId}`:`user extension ${e.extensionId}`:e.isDefault?"built-in":"user"}const Ut=/^(cursor|delete|undo|redo|tab|editor\.action\.clipboard)/;class Ht extends c.jG{get onDidUpdateKeybindings(){return this._onDidUpdateKeybindings?this._onDidUpdateKeybindings.event:Q.Jh.None}get inChordMode(){return this._currentChords.length>0}constructor(e,t,i,s,n){super(),this._contextKeyService=e,this._commandService=t,this._telemetryService=i,this._notificationService=s,this._logService=n,this._onDidUpdateKeybindings=this._register(new Q.vl),this._currentChords=[],this._currentChordChecker=new m.vb,this._currentChordStatusMessage=null,this._ignoreSingleModifiers=Bt.EMPTY,this._currentSingleModifier=null,this._currentSingleModifierClearTimeout=new m.pc,this._currentlyDispatchingCommandId=null,this._logging=!1}dispose(){super.dispose()}_log(e){this._logging&&this._logService.info(`[KeybindingService]: ${e}`)}getKeybindings(){return this._getResolver().getKeybindings()}lookupKeybinding(e,t){const i=this._getResolver().lookupPrimaryKeybinding(e,t||this._contextKeyService);if(i)return i.resolvedKeybinding}dispatchEvent(e,t){return this._dispatch(e,t)}softDispatch(e,t){this._log("/ Soft dispatching keyboard event");const i=this.resolveKeyboardEvent(e);if(i.hasMultipleChords())return console.warn("keyboard event should not be mapped to multiple chords"),Ot;const[s]=i.getDispatchChords();if(null===s)return this._log("\\ Keyboard event cannot be dispatched"),Ot;const n=this._contextKeyService.getContext(t),r=this._currentChords.map((({keypress:e})=>e));return this._getResolver().resolve(n,r,s)}_scheduleLeaveChordMode(){const e=Date.now();this._currentChordChecker.cancelAndSet((()=>{this._documentHasFocus()?Date.now()-e>5e3&&this._leaveChordMode():this._leaveChordMode()}),500)}_expectAnotherChord(e,t){switch(this._currentChords.push({keypress:e,label:t}),this._currentChords.length){case 0:throw(0,v.iH)("impossible");case 1:this._currentChordStatusMessage=this._notificationService.status(b.kg("first.chord","({0}) was pressed. Waiting for second key of chord...",t));break;default:{const e=this._currentChords.map((({label:e})=>e)).join(", ");this._currentChordStatusMessage=this._notificationService.status(b.kg("next.chord","({0}) was pressed. Waiting for next key of chord...",e))}}this._scheduleLeaveChordMode(),It.M.enabled&&It.M.disable()}_leaveChordMode(){this._currentChordStatusMessage&&(this._currentChordStatusMessage.dispose(),this._currentChordStatusMessage=null),this._currentChordChecker.cancel(),this._currentChords=[],It.M.enable()}_dispatch(e,t){return this._doDispatch(this.resolveKeyboardEvent(e),t,!1)}_singleModifierDispatch(e,t){const i=this.resolveKeyboardEvent(e),[s]=i.getSingleModifierDispatchChords();if(s)return this._ignoreSingleModifiers.has(s)?(this._log(`+ Ignoring single modifier ${s} due to it being pressed together with other keys.`),this._ignoreSingleModifiers=Bt.EMPTY,this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,!1):(this._ignoreSingleModifiers=Bt.EMPTY,null===this._currentSingleModifier?(this._log(`+ Storing single modifier for possible chord ${s}.`),this._currentSingleModifier=s,this._currentSingleModifierClearTimeout.cancelAndSet((()=>{this._log("+ Clearing single modifier due to 300ms elapsed."),this._currentSingleModifier=null}),300),!1):s===this._currentSingleModifier?(this._log(`/ Dispatching single modifier chord ${s} ${s}`),this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,this._doDispatch(i,t,!0)):(this._log(`+ Clearing single modifier due to modifier mismatch: ${this._currentSingleModifier} ${s}`),this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,!1));const[n]=i.getChords();return this._ignoreSingleModifiers=new Bt(n),null!==this._currentSingleModifier&&this._log("+ Clearing single modifier due to other key up."),this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,!1}_doDispatch(e,t,i=!1){let s=!1;if(e.hasMultipleChords())return console.warn("Unexpected keyboard event mapped to multiple chords"),!1;let n=null,r=null;if(i){const[t]=e.getSingleModifierDispatchChords();n=t,r=t?[t]:[]}else[n]=e.getDispatchChords(),r=this._currentChords.map((({keypress:e})=>e));if(null===n)return this._log("\\ Keyboard event cannot be dispatched in keydown phase."),s;const o=this._contextKeyService.getContext(t),a=e.getLabel(),c=this._getResolver().resolve(o,r,n);switch(c.kind){case 0:if(this._logService.trace("KeybindingService#dispatch",a,"[ No matching keybinding ]"),this.inChordMode){const e=this._currentChords.map((({label:e})=>e)).join(", ");this._log(`+ Leaving multi-chord mode: Nothing bound to "${e}, ${a}".`),this._notificationService.status(b.kg("missing.chord","The key combination ({0}, {1}) is not a command.",e,a),{hideAfter:1e4}),this._leaveChordMode(),s=!0}return s;case 1:return this._logService.trace("KeybindingService#dispatch",a,"[ Several keybindings match - more chords needed ]"),s=!0,this._expectAnotherChord(n,a),this._log(1===this._currentChords.length?"+ Entering multi-chord mode...":"+ Continuing multi-chord mode..."),s;case 2:if(this._logService.trace("KeybindingService#dispatch",a,`[ Will dispatch command ${c.commandId} ]`),null===c.commandId||""===c.commandId){if(this.inChordMode){const e=this._currentChords.map((({label:e})=>e)).join(", ");this._log(`+ Leaving chord mode: Nothing bound to "${e}, ${a}".`),this._notificationService.status(b.kg("missing.chord","The key combination ({0}, {1}) is not a command.",e,a),{hideAfter:1e4}),this._leaveChordMode(),s=!0}}else{this.inChordMode&&this._leaveChordMode(),c.isBubble||(s=!0),this._log(`+ Invoking command ${c.commandId}.`),this._currentlyDispatchingCommandId=c.commandId;try{"undefined"===typeof c.commandArgs?this._commandService.executeCommand(c.commandId).then(void 0,(e=>this._notificationService.warn(e))):this._commandService.executeCommand(c.commandId,c.commandArgs).then(void 0,(e=>this._notificationService.warn(e)))}finally{this._currentlyDispatchingCommandId=null}Ut.test(c.commandId)||this._telemetryService.publicLog2("workbenchActionExecuted",{id:c.commandId,from:"keybinding",detail:e.getUserSettingsLabel()??void 0})}return s}}mightProducePrintableCharacter(e){return!e.ctrlKey&&!e.metaKey&&(e.keyCode>=31&&e.keyCode<=56||e.keyCode>=21&&e.keyCode<=30)}}class Bt{static{this.EMPTY=new Bt(null)}constructor(e){this._ctrlKey=!!e&&e.ctrlKey,this._shiftKey=!!e&&e.shiftKey,this._altKey=!!e&&e.altKey,this._metaKey=!!e&&e.metaKey}has(e){switch(e){case"ctrl":return this._ctrlKey;case"shift":return this._shiftKey;case"alt":return this._altKey;case"meta":return this._metaKey}}}var Wt=i(59261);class Vt{constructor(e,t,i,s,n,r,o){this._resolvedKeybindingItemBrand=void 0,this.resolvedKeybinding=e,this.chords=e?zt(e.getDispatchChords()):[],e&&0===this.chords.length&&(this.chords=zt(e.getSingleModifierDispatchChords())),this.bubble=!!t&&94===t.charCodeAt(0),this.command=this.bubble?t.substr(1):t,this.commandArgs=i,this.when=s,this.isDefault=n,this.extensionId=r,this.isBuiltinExtension=o}}function zt(e){const t=[];for(let i=0,s=e.length;ithis._getLabel(e)))}getAriaLabel(){return jt.r0.toLabel(this._os,this._chords,(e=>this._getAriaLabel(e)))}getElectronAccelerator(){return this._chords.length>1||this._chords[0].isDuplicateModifierCase()?null:jt.rr.toLabel(this._os,this._chords,(e=>this._getElectronAccelerator(e)))}getUserSettingsLabel(){return jt.G$.toLabel(this._os,this._chords,(e=>this._getUserSettingsLabel(e)))}hasMultipleChords(){return this._chords.length>1}getChords(){return this._chords.map((e=>this._getChord(e)))}_getChord(e){return new ft.FW(e.ctrlKey,e.shiftKey,e.altKey,e.metaKey,this._getLabel(e),this._getAriaLabel(e))}getDispatchChords(){return this._chords.map((e=>this._getChordDispatch(e)))}getSingleModifierDispatchChords(){return this._chords.map((e=>this._getSingleModifierChordDispatch(e)))}}class Yt extends Kt{constructor(e,t){super(t,e)}_keyCodeToUILabel(e){if(2===this._os)switch(e){case 15:return"\u2190";case 16:return"\u2191";case 17:return"\u2192";case 18:return"\u2193"}return Gt.YM.toString(e)}_getLabel(e){return e.isDuplicateModifierCase()?"":this._keyCodeToUILabel(e.keyCode)}_getAriaLabel(e){return e.isDuplicateModifierCase()?"":Gt.YM.toString(e.keyCode)}_getElectronAccelerator(e){return Gt.YM.toElectronAccelerator(e.keyCode)}_getUserSettingsLabel(e){if(e.isDuplicateModifierCase())return"";const t=Gt.YM.toUserSettingsUS(e.keyCode);return t?t.toLowerCase():t}_getChordDispatch(e){return Yt.getDispatchStr(e)}static getDispatchStr(e){if(e.isModifierKey())return null;let t="";return e.ctrlKey&&(t+="ctrl+"),e.shiftKey&&(t+="shift+"),e.altKey&&(t+="alt+"),e.metaKey&&(t+="meta+"),t+=Gt.YM.toString(e.keyCode),t}_getSingleModifierChordDispatch(e){return 5!==e.keyCode||e.shiftKey||e.altKey||e.metaKey?4!==e.keyCode||e.ctrlKey||e.altKey||e.metaKey?6!==e.keyCode||e.ctrlKey||e.shiftKey||e.metaKey?57!==e.keyCode||e.ctrlKey||e.shiftKey||e.altKey?null:"meta":"alt":"shift":"ctrl"}static _scanCodeToKeyCode(e){const t=Gt.Fo[e];if(-1!==t)return t;switch(e){case 10:return 31;case 11:return 32;case 12:return 33;case 13:return 34;case 14:return 35;case 15:return 36;case 16:return 37;case 17:return 38;case 18:return 39;case 19:return 40;case 20:return 41;case 21:return 42;case 22:return 43;case 23:return 44;case 24:return 45;case 25:return 46;case 26:return 47;case 27:return 48;case 28:return 49;case 29:return 50;case 30:return 51;case 31:return 52;case 32:return 53;case 33:return 54;case 34:return 55;case 35:return 56;case 36:return 22;case 37:return 23;case 38:return 24;case 39:return 25;case 40:return 26;case 41:return 27;case 42:return 28;case 43:return 29;case 44:return 30;case 45:return 21;case 51:return 88;case 52:return 86;case 53:return 92;case 54:return 94;case 55:return 93;case 56:return 0;case 57:return 85;case 58:return 95;case 59:return 91;case 60:return 87;case 61:return 89;case 62:return 90;case 106:return 97}return 0}static _toKeyCodeChord(e){if(!e)return null;if(e instanceof ft.dG)return e;const t=this._scanCodeToKeyCode(e.scanCode);return 0===t?null:new ft.dG(e.ctrlKey,e.shiftKey,e.altKey,e.metaKey,t)}static resolveKeybinding(e,t){const i=zt(e.chords.map((e=>this._toKeyCodeChord(e))));return i.length>0?[new Yt(i,t)]:[]}}var qt=i(67841),$t=i(73823),Qt=i(90651),Xt=i(37227),Zt=i(51861),Jt=i(89403),ei=i(51465),ti=i(17890),ii=i(36921),si=i(57629),ni=i(27195),ri=i(47358),oi=i(60413),ai=i(25154),ci=i(11799),li=i(5646),hi=i(31295),di=i(10350),ui=i(18956),gi=i(25689),pi=i(37882);const mi=/\(&([^\s&])\)|(^|[^&])&([^\s&])/,fi=/(&)?(&)([^\s&])/g;var _i,vi;!function(e){e[e.Right=0]="Right",e[e.Left=1]="Left"}(_i||(_i={})),function(e){e[e.Above=0]="Above",e[e.Below=1]="Below"}(vi||(vi={}));class Ci extends ci.E{constructor(e,t,i,s){e.classList.add("monaco-menu-container"),e.setAttribute("role","presentation");const n=document.createElement("div");n.classList.add("monaco-menu"),n.setAttribute("role","presentation"),super(n,{orientation:1,actionViewItemProvider:e=>this.doGetActionViewItem(e,i,r),context:i.context,actionRunner:i.actionRunner,ariaLabel:i.ariaLabel,ariaRole:"menu",focusOnlyEnabledItems:!0,triggerKeys:{keys:[3,...We.zx||We.j9?[10]:[]],keyDown:!0}}),this.menuStyles=s,this.menuElement=n,this.actionsList.tabIndex=0,this.initializeOrUpdateStyleSheet(e,s),this._register(ai.q.addTarget(n)),this._register((0,U.ko)(n,U.Bx.KEY_DOWN,(e=>{new Xe.Z(e).equals(2)&&e.preventDefault()}))),i.enableMnemonics&&this._register((0,U.ko)(n,U.Bx.KEY_DOWN,(e=>{const t=e.key.toLocaleLowerCase();if(this.mnemonics.has(t)){U.fs.stop(e,!0);const i=this.mnemonics.get(t);if(1===i.length&&(i[0]instanceof bi&&i[0].container&&this.focusItemByElement(i[0].container),i[0].onClick(e)),i.length>1){const e=i.shift();e&&e.container&&(this.focusItemByElement(e.container),i.push(e)),this.mnemonics.set(t,i)}}}))),We.j9&&this._register((0,U.ko)(n,U.Bx.KEY_DOWN,(e=>{const t=new Xe.Z(e);t.equals(14)||t.equals(11)?(this.focusedItem=this.viewItems.length-1,this.focusNext(),U.fs.stop(e,!0)):(t.equals(13)||t.equals(12))&&(this.focusedItem=0,this.focusPrevious(),U.fs.stop(e,!0))}))),this._register((0,U.ko)(this.domNode,U.Bx.MOUSE_OUT,(e=>{const t=e.relatedTarget;(0,U.QX)(t,this.domNode)||(this.focusedItem=void 0,this.updateFocus(),e.stopPropagation())}))),this._register((0,U.ko)(this.actionsList,U.Bx.MOUSE_OVER,(e=>{let t=e.target;if(t&&(0,U.QX)(t,this.actionsList)&&t!==this.actionsList){for(;t.parentElement!==this.actionsList&&null!==t.parentElement;)t=t.parentElement;if(t.classList.contains("action-item")){const e=this.focusedItem;this.setFocusedItem(t),e!==this.focusedItem&&this.updateFocus()}}}))),this._register(ai.q.addTarget(this.actionsList)),this._register((0,U.ko)(this.actionsList,ai.B.Tap,(e=>{let t=e.initialTarget;if(t&&(0,U.QX)(t,this.actionsList)&&t!==this.actionsList){for(;t.parentElement!==this.actionsList&&null!==t.parentElement;)t=t.parentElement;if(t.classList.contains("action-item")){const e=this.focusedItem;this.setFocusedItem(t),e!==this.focusedItem&&this.updateFocus()}}})));const r={parent:this};this.mnemonics=new Map,this.scrollableElement=this._register(new hi.MU(n,{alwaysConsumeMouseWheel:!0,horizontal:2,vertical:3,verticalScrollbarSize:7,handleMouseWheel:!0,useShadows:!0}));const o=this.scrollableElement.getDomNode();o.style.position="",this.styleScrollElement(o,s),this._register((0,U.ko)(n,ai.B.Change,(e=>{U.fs.stop(e,!0);const t=this.scrollableElement.getScrollPosition().scrollTop;this.scrollableElement.setScrollPosition({scrollTop:t-e.translationY})}))),this._register((0,U.ko)(o,U.Bx.MOUSE_UP,(e=>{e.preventDefault()})));const a=(0,U.zk)(e);n.style.maxHeight=`${Math.max(10,a.innerHeight-e.getBoundingClientRect().top-35)}px`,t=t.filter(((e,s)=>{if(i.submenuIds?.has(e.id))return console.warn(`Found submenu cycle: ${e.id}`),!1;if(e instanceof ii.wv){if(s===t.length-1||0===s)return!1;if(t[s-1]instanceof ii.wv)return!1}return!0})),this.push(t,{icon:!0,label:!0,isMenu:!0}),e.appendChild(this.scrollableElement.getDomNode()),this.scrollableElement.scanDomNode(),this.viewItems.filter((e=>!(e instanceof Si))).forEach(((e,t,i)=>{e.updatePositionInSet(t+1,i.length)}))}initializeOrUpdateStyleSheet(e,t){this.styleSheet||((0,U.Cl)(e)?this.styleSheet=(0,U.li)(e):(Ci.globalStyleSheet||(Ci.globalStyleSheet=(0,U.li)()),this.styleSheet=Ci.globalStyleSheet)),this.styleSheet.textContent=function(e,t){let i=`\n.monaco-menu {\n\tfont-size: 13px;\n\tborder-radius: 5px;\n\tmin-width: 160px;\n}\n\n${yi(di.W.menuSelection)}\n${yi(di.W.menuSubmenu)}\n\n.monaco-menu .monaco-action-bar {\n\ttext-align: right;\n\toverflow: hidden;\n\twhite-space: nowrap;\n}\n\n.monaco-menu .monaco-action-bar .actions-container {\n\tdisplay: flex;\n\tmargin: 0 auto;\n\tpadding: 0;\n\twidth: 100%;\n\tjustify-content: flex-end;\n}\n\n.monaco-menu .monaco-action-bar.vertical .actions-container {\n\tdisplay: inline-block;\n}\n\n.monaco-menu .monaco-action-bar.reverse .actions-container {\n\tflex-direction: row-reverse;\n}\n\n.monaco-menu .monaco-action-bar .action-item {\n\tcursor: pointer;\n\tdisplay: inline-block;\n\ttransition: transform 50ms ease;\n\tposition: relative; /* DO NOT REMOVE - this is the key to preventing the ghosting icon bug in Chrome 42 */\n}\n\n.monaco-menu .monaco-action-bar .action-item.disabled {\n\tcursor: default;\n}\n\n.monaco-menu .monaco-action-bar .action-item .icon,\n.monaco-menu .monaco-action-bar .action-item .codicon {\n\tdisplay: inline-block;\n}\n\n.monaco-menu .monaco-action-bar .action-item .codicon {\n\tdisplay: flex;\n\talign-items: center;\n}\n\n.monaco-menu .monaco-action-bar .action-label {\n\tfont-size: 11px;\n\tmargin-right: 4px;\n}\n\n.monaco-menu .monaco-action-bar .action-item.disabled .action-label,\n.monaco-menu .monaco-action-bar .action-item.disabled .action-label:hover {\n\tcolor: var(--vscode-disabledForeground);\n}\n\n/* Vertical actions */\n\n.monaco-menu .monaco-action-bar.vertical {\n\ttext-align: left;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item {\n\tdisplay: block;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\tdisplay: block;\n\tborder-bottom: 1px solid var(--vscode-menu-separatorBackground);\n\tpadding-top: 1px;\n\tpadding: 30px;\n}\n\n.monaco-menu .secondary-actions .monaco-action-bar .action-label {\n\tmargin-left: 6px;\n}\n\n/* Action Items */\n.monaco-menu .monaco-action-bar .action-item.select-container {\n\toverflow: hidden; /* somehow the dropdown overflows its container, we prevent it here to not push */\n\tflex: 1;\n\tmax-width: 170px;\n\tmin-width: 60px;\n\tdisplay: flex;\n\talign-items: center;\n\tjustify-content: center;\n\tmargin-right: 10px;\n}\n\n.monaco-menu .monaco-action-bar.vertical {\n\tmargin-left: 0;\n\toverflow: visible;\n}\n\n.monaco-menu .monaco-action-bar.vertical .actions-container {\n\tdisplay: block;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item {\n\tpadding: 0;\n\ttransform: none;\n\tdisplay: flex;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item.active {\n\ttransform: none;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item {\n\tflex: 1 1 auto;\n\tdisplay: flex;\n\theight: 2em;\n\talign-items: center;\n\tposition: relative;\n\tmargin: 0 4px;\n\tborder-radius: 4px;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item:hover .keybinding,\n.monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .keybinding {\n\topacity: unset;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label {\n\tflex: 1 1 auto;\n\ttext-decoration: none;\n\tpadding: 0 1em;\n\tbackground: none;\n\tfont-size: 12px;\n\tline-height: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .keybinding,\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\tdisplay: inline-block;\n\tflex: 2 1 auto;\n\tpadding: 0 1em;\n\ttext-align: right;\n\tfont-size: 12px;\n\tline-height: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\theight: 100%;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator.codicon {\n\tfont-size: 16px !important;\n\tdisplay: flex;\n\talign-items: center;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator.codicon::before {\n\tmargin-left: auto;\n\tmargin-right: -20px;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item.disabled .keybinding,\n.monaco-menu .monaco-action-bar.vertical .action-item.disabled .submenu-indicator {\n\topacity: 0.4;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label:not(.separator) {\n\tdisplay: inline-block;\n\tbox-sizing: border-box;\n\tmargin: 0;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item {\n\tposition: static;\n\toverflow: visible;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item .monaco-submenu {\n\tposition: absolute;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\twidth: 100%;\n\theight: 0px !important;\n\topacity: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator.text {\n\tpadding: 0.7em 1em 0.1em 1em;\n\tfont-weight: bold;\n\topacity: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label:hover {\n\tcolor: inherit;\n}\n\n.monaco-menu .monaco-action-bar.vertical .menu-item-check {\n\tposition: absolute;\n\tvisibility: hidden;\n\twidth: 1em;\n\theight: 100%;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item.checked .menu-item-check {\n\tvisibility: visible;\n\tdisplay: flex;\n\talign-items: center;\n\tjustify-content: center;\n}\n\n/* Context Menu */\n\n.context-view.monaco-menu-container {\n\toutline: 0;\n\tborder: none;\n\tanimation: fadeIn 0.083s linear;\n\t-webkit-app-region: no-drag;\n}\n\n.context-view.monaco-menu-container :focus,\n.context-view.monaco-menu-container .monaco-action-bar.vertical:focus,\n.context-view.monaco-menu-container .monaco-action-bar.vertical :focus {\n\toutline: 0;\n}\n\n.hc-black .context-view.monaco-menu-container,\n.hc-light .context-view.monaco-menu-container,\n:host-context(.hc-black) .context-view.monaco-menu-container,\n:host-context(.hc-light) .context-view.monaco-menu-container {\n\tbox-shadow: none;\n}\n\n.hc-black .monaco-menu .monaco-action-bar.vertical .action-item.focused,\n.hc-light .monaco-menu .monaco-action-bar.vertical .action-item.focused,\n:host-context(.hc-black) .monaco-menu .monaco-action-bar.vertical .action-item.focused,\n:host-context(.hc-light) .monaco-menu .monaco-action-bar.vertical .action-item.focused {\n\tbackground: none;\n}\n\n/* Vertical Action Bar Styles */\n\n.monaco-menu .monaco-action-bar.vertical {\n\tpadding: 4px 0;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item {\n\theight: 2em;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label:not(.separator),\n.monaco-menu .monaco-action-bar.vertical .keybinding {\n\tfont-size: inherit;\n\tpadding: 0 2em;\n\tmax-height: 100%;\n}\n\n.monaco-menu .monaco-action-bar.vertical .menu-item-check {\n\tfont-size: inherit;\n\twidth: 2em;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\tfont-size: inherit;\n\tmargin: 5px 0 !important;\n\tpadding: 0;\n\tborder-radius: 0;\n}\n\n.linux .monaco-menu .monaco-action-bar.vertical .action-label.separator,\n:host-context(.linux) .monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\tmargin-left: 0;\n\tmargin-right: 0;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\tfont-size: 60%;\n\tpadding: 0 1.8em;\n}\n\n.linux .monaco-menu .monaco-action-bar.vertical .submenu-indicator,\n:host-context(.linux) .monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\theight: 100%;\n\tmask-size: 10px 10px;\n\t-webkit-mask-size: 10px 10px;\n}\n\n.monaco-menu .action-item {\n\tcursor: default;\n}`;if(t){i+="\n\t\t\t/* Arrows */\n\t\t\t.monaco-scrollable-element > .scrollbar > .scra {\n\t\t\t\tcursor: pointer;\n\t\t\t\tfont-size: 11px !important;\n\t\t\t}\n\n\t\t\t.monaco-scrollable-element > .visible {\n\t\t\t\topacity: 1;\n\n\t\t\t\t/* Background rule added for IE9 - to allow clicks on dom node */\n\t\t\t\tbackground:rgba(0,0,0,0);\n\n\t\t\t\ttransition: opacity 100ms linear;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .invisible {\n\t\t\t\topacity: 0;\n\t\t\t\tpointer-events: none;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .invisible.fade {\n\t\t\t\ttransition: opacity 800ms linear;\n\t\t\t}\n\n\t\t\t/* Scrollable Content Inset Shadow */\n\t\t\t.monaco-scrollable-element > .shadow {\n\t\t\t\tposition: absolute;\n\t\t\t\tdisplay: none;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .shadow.top {\n\t\t\t\tdisplay: block;\n\t\t\t\ttop: 0;\n\t\t\t\tleft: 3px;\n\t\t\t\theight: 3px;\n\t\t\t\twidth: 100%;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .shadow.left {\n\t\t\t\tdisplay: block;\n\t\t\t\ttop: 3px;\n\t\t\t\tleft: 0;\n\t\t\t\theight: 100%;\n\t\t\t\twidth: 3px;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .shadow.top-left-corner {\n\t\t\t\tdisplay: block;\n\t\t\t\ttop: 0;\n\t\t\t\tleft: 0;\n\t\t\t\theight: 3px;\n\t\t\t\twidth: 3px;\n\t\t\t}\n\t\t";const t=e.scrollbarShadow;t&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .shadow.top {\n\t\t\t\t\tbox-shadow: ${t} 0 6px 6px -6px inset;\n\t\t\t\t}\n\n\t\t\t\t.monaco-scrollable-element > .shadow.left {\n\t\t\t\t\tbox-shadow: ${t} 6px 0 6px -6px inset;\n\t\t\t\t}\n\n\t\t\t\t.monaco-scrollable-element > .shadow.top.left {\n\t\t\t\t\tbox-shadow: ${t} 6px 6px 6px -6px inset;\n\t\t\t\t}\n\t\t\t`);const s=e.scrollbarSliderBackground;s&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .scrollbar > .slider {\n\t\t\t\t\tbackground: ${s};\n\t\t\t\t}\n\t\t\t`);const n=e.scrollbarSliderHoverBackground;n&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .scrollbar > .slider:hover {\n\t\t\t\t\tbackground: ${n};\n\t\t\t\t}\n\t\t\t`);const r=e.scrollbarSliderActiveBackground;r&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .scrollbar > .slider.active {\n\t\t\t\t\tbackground: ${r};\n\t\t\t\t}\n\t\t\t`)}return i}(t,(0,U.Cl)(e))}styleScrollElement(e,t){const i=t.foregroundColor??"",s=t.backgroundColor??"",n=t.borderColor?`1px solid ${t.borderColor}`:"",r=t.shadowColor?`0 2px 8px ${t.shadowColor}`:"";e.style.outline=n,e.style.borderRadius="5px",e.style.color=i,e.style.backgroundColor=s,e.style.boxShadow=r}getContainer(){return this.scrollableElement.getDomNode()}get onScroll(){return this.scrollableElement.onScroll}focusItemByElement(e){const t=this.focusedItem;this.setFocusedItem(e),t!==this.focusedItem&&this.updateFocus()}setFocusedItem(e){for(let t=0;t{this.element&&(this._register((0,U.ko)(this.element,U.Bx.MOUSE_UP,(e=>{if(U.fs.stop(e,!0),oi.gm){if(new ri.P((0,U.zk)(this.element),e).rightButton)return;this.onClick(e)}else setTimeout((()=>{this.onClick(e)}),0)}))),this._register((0,U.ko)(this.element,U.Bx.CONTEXT_MENU,(e=>{U.fs.stop(e,!0)}))))}),100),this._register(this.runOnceToEnableMouseUp)}render(e){super.render(e),this.element&&(this.container=e,this.item=(0,U.BC)(this.element,(0,U.$)("a.action-menu-item")),this._action.id===ii.wv.ID?this.item.setAttribute("role","presentation"):(this.item.setAttribute("role","menuitem"),this.mnemonic&&this.item.setAttribute("aria-keyshortcuts",`${this.mnemonic}`)),this.check=(0,U.BC)(this.item,(0,U.$)("span.menu-item-check"+gi.L.asCSSSelector(di.W.menuSelection))),this.check.setAttribute("role","none"),this.label=(0,U.BC)(this.item,(0,U.$)("span.action-label")),this.options.label&&this.options.keybinding&&((0,U.BC)(this.item,(0,U.$)("span.keybinding")).textContent=this.options.keybinding),this.runOnceToEnableMouseUp.schedule(),this.updateClass(),this.updateLabel(),this.updateTooltip(),this.updateEnabled(),this.updateChecked(),this.applyStyle())}blur(){super.blur(),this.applyStyle()}focus(){super.focus(),this.item?.focus(),this.applyStyle()}updatePositionInSet(e,t){this.item&&(this.item.setAttribute("aria-posinset",`${e}`),this.item.setAttribute("aria-setsize",`${t}`))}updateLabel(){if(this.label&&this.options.label){(0,U.w_)(this.label);let e=(0,pi.pS)(this.action.label);if(e){const t=function(e){const t=mi,i=t.exec(e);if(!i)return e;const s=!i[1];return e.replace(t,s?"$2$3":"").trim()}(e);this.options.enableMnemonics||(e=t),this.label.setAttribute("aria-label",t.replace(/&&/g,"&"));const i=mi.exec(e);if(i){e=l.ih(e),fi.lastIndex=0;let t=fi.exec(e);for(;t&&t[1];)t=fi.exec(e);const s=e=>e.replace(/&&/g,"&");t?this.label.append(l.NB(s(e.substr(0,t.index))," "),(0,U.$)("u",{"aria-hidden":"true"},t[3]),l.BO(s(e.substr(t.index+t[0].length))," ")):this.label.innerText=s(e).trim(),this.item?.setAttribute("aria-keyshortcuts",(i[1]?i[1]:i[3]).toLocaleLowerCase())}else this.label.innerText=e.replace(/&&/g,"&").trim()}}}updateTooltip(){}updateClass(){this.cssClass&&this.item&&this.item.classList.remove(...this.cssClass.split(" ")),this.options.icon&&this.label?(this.cssClass=this.action.class||"",this.label.classList.add("icon"),this.cssClass&&this.label.classList.add(...this.cssClass.split(" ")),this.updateEnabled()):this.label&&this.label.classList.remove("icon")}updateEnabled(){this.action.enabled?(this.element&&(this.element.classList.remove("disabled"),this.element.removeAttribute("aria-disabled")),this.item&&(this.item.classList.remove("disabled"),this.item.removeAttribute("aria-disabled"),this.item.tabIndex=0)):(this.element&&(this.element.classList.add("disabled"),this.element.setAttribute("aria-disabled","true")),this.item&&(this.item.classList.add("disabled"),this.item.setAttribute("aria-disabled","true")))}updateChecked(){if(!this.item)return;const e=this.action.checked;this.item.classList.toggle("checked",!!e),void 0!==e?(this.item.setAttribute("role","menuitemcheckbox"),this.item.setAttribute("aria-checked",e?"true":"false")):(this.item.setAttribute("role","menuitem"),this.item.setAttribute("aria-checked",""))}getMnemonic(){return this.mnemonic}applyStyle(){const e=this.element&&this.element.classList.contains("focused"),t=e&&this.menuStyle.selectionForegroundColor?this.menuStyle.selectionForegroundColor:this.menuStyle.foregroundColor,i=e&&this.menuStyle.selectionBackgroundColor?this.menuStyle.selectionBackgroundColor:void 0,s=e&&this.menuStyle.selectionBorderColor?`1px solid ${this.menuStyle.selectionBorderColor}`:"",n=e&&this.menuStyle.selectionBorderColor?"-1px":"";this.item&&(this.item.style.color=t??"",this.item.style.backgroundColor=i??"",this.item.style.outline=s,this.item.style.outlineOffset=n),this.check&&(this.check.style.color=t??"")}}class bi extends Ei{constructor(e,t,i,s,n){super(e,e,s,n),this.submenuActions=t,this.parentData=i,this.submenuOptions=s,this.mysubmenu=null,this.submenuDisposables=this._register(new c.Cm),this.mouseOver=!1,this.expandDirection=s&&void 0!==s.expandDirection?s.expandDirection:{horizontal:_i.Right,vertical:vi.Below},this.showScheduler=new m.uC((()=>{this.mouseOver&&(this.cleanupExistingSubmenu(!1),this.createSubmenu(!1))}),250),this.hideScheduler=new m.uC((()=>{this.element&&!(0,U.QX)((0,U.bq)(),this.element)&&this.parentData.submenu===this.mysubmenu&&(this.parentData.parent.focus(!1),this.cleanupExistingSubmenu(!0))}),750)}render(e){super.render(e),this.element&&(this.item&&(this.item.classList.add("monaco-submenu-item"),this.item.tabIndex=0,this.item.setAttribute("aria-haspopup","true"),this.updateAriaExpanded("false"),this.submenuIndicator=(0,U.BC)(this.item,(0,U.$)("span.submenu-indicator"+gi.L.asCSSSelector(di.W.menuSubmenu))),this.submenuIndicator.setAttribute("aria-hidden","true")),this._register((0,U.ko)(this.element,U.Bx.KEY_UP,(e=>{const t=new Xe.Z(e);(t.equals(17)||t.equals(3))&&(U.fs.stop(e,!0),this.createSubmenu(!0))}))),this._register((0,U.ko)(this.element,U.Bx.KEY_DOWN,(e=>{const t=new Xe.Z(e);(0,U.bq)()===this.item&&(t.equals(17)||t.equals(3))&&U.fs.stop(e,!0)}))),this._register((0,U.ko)(this.element,U.Bx.MOUSE_OVER,(e=>{this.mouseOver||(this.mouseOver=!0,this.showScheduler.schedule())}))),this._register((0,U.ko)(this.element,U.Bx.MOUSE_LEAVE,(e=>{this.mouseOver=!1}))),this._register((0,U.ko)(this.element,U.Bx.FOCUS_OUT,(e=>{this.element&&!(0,U.QX)((0,U.bq)(),this.element)&&this.hideScheduler.schedule()}))),this._register(this.parentData.parent.onScroll((()=>{this.parentData.submenu===this.mysubmenu&&(this.parentData.parent.focus(!1),this.cleanupExistingSubmenu(!0))}))))}updateEnabled(){}onClick(e){U.fs.stop(e,!0),this.cleanupExistingSubmenu(!1),this.createSubmenu(!0)}cleanupExistingSubmenu(e){if(this.parentData.submenu&&(e||this.parentData.submenu!==this.mysubmenu)){try{this.parentData.submenu.dispose()}catch{}this.parentData.submenu=void 0,this.updateAriaExpanded("false"),this.submenuContainer&&(this.submenuDisposables.clear(),this.submenuContainer=void 0)}}calculateSubmenuMenuLayout(e,t,i,s){const n={top:0,left:0};return n.left=et(e.width,t.width,{position:s.horizontal===_i.Right?0:1,offset:i.left,size:i.width}),n.left>=i.left&&n.left{new Xe.Z(e).equals(15)&&(U.fs.stop(e,!0),this.parentData.parent.focus(),this.cleanupExistingSubmenu(!0))}))),this.submenuDisposables.add((0,U.ko)(this.submenuContainer,U.Bx.KEY_DOWN,(e=>{new Xe.Z(e).equals(15)&&U.fs.stop(e,!0)}))),this.submenuDisposables.add(this.parentData.submenu.onDidCancel((()=>{this.parentData.parent.focus(),this.cleanupExistingSubmenu(!0)}))),this.parentData.submenu.focus(e),this.mysubmenu=this.parentData.submenu}}updateAriaExpanded(e){this.item&&this.item?.setAttribute("aria-expanded",e)}applyStyle(){super.applyStyle();const e=this.element&&this.element.classList.contains("focused")&&this.menuStyle.selectionForegroundColor?this.menuStyle.selectionForegroundColor:this.menuStyle.foregroundColor;this.submenuIndicator&&(this.submenuIndicator.style.color=e??"")}dispose(){super.dispose(),this.hideScheduler.dispose(),this.mysubmenu&&(this.mysubmenu.dispose(),this.mysubmenu=null),this.submenuContainer&&(this.submenuContainer=void 0)}}class Si extends li.Z4{constructor(e,t,i,s){super(e,t,i),this.menuStyles=s}render(e){super.render(e),this.label&&(this.label.style.borderBottomColor=this.menuStyles.separatorColor?`${this.menuStyles.separatorColor}`:"")}}function yi(e){const t=(0,ui.J)()[e.id];return`.codicon-${e.id}:before { content: '\\${t.toString(16)}'; }`}var wi=i(19070);class Ri{constructor(e,t,i,s){this.contextViewService=e,this.telemetryService=t,this.notificationService=i,this.keybindingService=s,this.focusToReturn=null,this.lastContainer=null,this.block=null,this.blockDisposable=null,this.options={blockMouse:!0}}configure(e){this.options=e}showContextMenu(e){const t=e.getActions();if(!t.length)return;let i;this.focusToReturn=(0,U.bq)();const s=(0,U.sb)(e.domForShadowRoot)?e.domForShadowRoot:void 0;this.contextViewService.showContextView({getAnchor:()=>e.getAnchor(),canRelayout:!1,anchorAlignment:e.anchorAlignment,anchorAxisAlignment:e.anchorAxisAlignment,render:s=>{this.lastContainer=s;const n=e.getMenuClassName?e.getMenuClassName():"";n&&(s.className+=" "+n),this.options.blockMouse&&(this.block=s.appendChild((0,U.$)(".context-view-block")),this.block.style.position="fixed",this.block.style.cursor="initial",this.block.style.left="0",this.block.style.top="0",this.block.style.width="100%",this.block.style.height="100%",this.block.style.zIndex="-1",this.blockDisposable?.dispose(),this.blockDisposable=(0,U.ko)(this.block,U.Bx.MOUSE_DOWN,(e=>e.stopPropagation())));const r=new c.Cm,o=e.actionRunner||new ii.LN;o.onWillRun((t=>this.onActionRun(t,!e.skipTelemetry)),this,r),o.onDidRun(this.onDidActionRun,this,r),i=new Ci(s,t,{actionViewItemProvider:e.getActionViewItem,context:e.getActionsContext?e.getActionsContext():null,actionRunner:o,getKeyBinding:e.getKeyBinding?e.getKeyBinding:e=>this.keybindingService.lookupKeybinding(e.id)},wi.XS),i.onDidCancel((()=>this.contextViewService.hideContextView(!0)),null,r),i.onDidBlur((()=>this.contextViewService.hideContextView(!0)),null,r);const a=(0,U.zk)(s);return r.add((0,U.ko)(a,U.Bx.BLUR,(()=>this.contextViewService.hideContextView(!0)))),r.add((0,U.ko)(a,U.Bx.MOUSE_DOWN,(e=>{if(e.defaultPrevented)return;const t=new ri.P(a,e);let i=t.target;if(!t.rightButton){for(;i;){if(i===s)return;i=i.parentElement}this.contextViewService.hideContextView(!0)}}))),(0,c.qE)(r,i)},focus:()=>{i?.focus(!!e.autoSelectFirstItem)},onHide:t=>{e.onHide?.(!!t),this.block&&(this.block.remove(),this.block=null),this.blockDisposable?.dispose(),this.blockDisposable=null,this.lastContainer&&((0,U.bq)()===this.lastContainer||(0,U.QX)((0,U.bq)(),this.lastContainer))&&this.focusToReturn?.focus(),this.lastContainer=null}},s,!!s)}onActionRun(e,t){t&&this.telemetryService.publicLog2("workbenchActionExecuted",{id:e.action.id,from:"contextMenu"}),this.contextViewService.hideContextView(!1)}onDidActionRun(e){e.error&&!(0,v.MB)(e.error)&&this.notificationService.error(e.error)}}var Li=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ti=function(e,t){return function(i,s){t(i,s,e)}};let xi=class extends c.jG{get contextMenuHandler(){return this._contextMenuHandler||(this._contextMenuHandler=new Ri(this.contextViewService,this.telemetryService,this.notificationService,this.keybindingService)),this._contextMenuHandler}constructor(e,t,i,s,n,r){super(),this.telemetryService=e,this.notificationService=t,this.contextViewService=i,this.keybindingService=s,this.menuService=n,this.contextKeyService=r,this._contextMenuHandler=void 0,this._onDidShowContextMenu=this._store.add(new Q.vl),this.onDidShowContextMenu=this._onDidShowContextMenu.event,this._onDidHideContextMenu=this._store.add(new Q.vl)}configure(e){this.contextMenuHandler.configure(e)}showContextMenu(e){e=ki.transform(e,this.menuService,this.contextKeyService),this.contextMenuHandler.showContextMenu({...e,onHide:t=>{e.onHide?.(t),this._onDidHideContextMenu.fire()}}),U.Di.getInstance().resetKeyStatus(),this._onDidShowContextMenu.fire()}};var ki;xi=Li([Ti(0,Qt.k),Ti(1,me.Ot),Ti(2,Oe.l),Ti(3,De.b),Ti(4,ni.ez),Ti(5,ie.fN)],xi),function(e){e.transform=function(e,t,i){if(!((s=e)&&s.menuId instanceof ni.D8))return e;var s;const{menuId:n,menuActionOptions:r,contextKeyService:o}=e;return{...e,getActions:()=>{const s=[];if(n){const e=t.getMenuActions(n,o??i,r);(0,si.$u)(e,s)}return e.getActions?ii.wv.join(e.getActions(),s):s}}}}(ki||(ki={}));var Ai,Ni=i(908);!function(e){e[e.API=0]="API",e[e.USER=1]="USER"}(Ai||(Ai={}));var Ii=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Oi=function(e,t){return function(i,s){t(i,s,e)}};let Di=class{constructor(e){this._commandService=e}async open(e,t){if(!(0,C.v$)(e,C.ny.command))return!1;if(!t?.allowCommands)return!0;if("string"===typeof e&&(e=h.r.parse(e)),Array.isArray(t.allowCommands)&&!t.allowCommands.includes(e.path))return!0;let i=[];try{i=(0,Ni.qg)(decodeURIComponent(e.query))}catch{try{i=(0,Ni.qg)(e.query)}catch{}}return Array.isArray(i)||(i=[i]),await this._commandService.executeCommand(e.path,...i),!0}};Di=Ii([Oi(0,St.d)],Di);let Mi=class{constructor(e){this._editorService=e}async open(e,t){"string"===typeof e&&(e=h.r.parse(e));const{selection:i,uri:s}=(0,Ue.e)(e);return(e=s).scheme===C.ny.file&&(e=(0,Jt.Fd)(e)),await this._editorService.openCodeEditor({resource:e,options:{selection:i,source:t?.fromUserGesture?Ai.USER:Ai.API,...t?.editorOptions}},this._editorService.getFocusedCodeEditor(),t?.openToSide),!0}};Mi=Ii([Oi(0,g.T)],Mi);let Pi=class{constructor(e,t){this._openers=new X.w,this._validators=new X.w,this._resolvers=new X.w,this._resolvedUriTargets=new yt.fT((e=>e.with({path:null,fragment:null,query:null}).toString())),this._externalOpeners=new X.w,this._defaultExternalOpener={openExternal:async e=>((0,C.fV)(e,C.ny.http,C.ny.https)?U.CE(e):a.G.location.href=e,!0)},this._openers.push({open:async(e,t)=>!(!t?.openExternal&&!(0,C.fV)(e,C.ny.mailto,C.ny.http,C.ny.https,C.ny.vsls))&&(await this._doOpenExternal(e,t),!0)}),this._openers.push(new Di(t)),this._openers.push(new Mi(e))}registerOpener(e){return{dispose:this._openers.unshift(e)}}async open(e,t){const i="string"===typeof e?h.r.parse(e):e,s=this._resolvedUriTargets.get(i)??e;for(const n of this._validators)if(!await n.shouldOpen(s,t))return!1;for(const n of this._openers){if(await n.open(e,t))return!0}return!1}async resolveExternalUri(e,t){for(const i of this._resolvers)try{const s=await i.resolveExternalUri(e,t);if(s)return this._resolvedUriTargets.has(s.resolved)||this._resolvedUriTargets.set(s.resolved,e),s}catch{}throw new Error("Could not resolve external URI: "+e.toString())}async _doOpenExternal(e,t){const i="string"===typeof e?h.r.parse(e):e;let s,n;try{s=(await this.resolveExternalUri(i,t)).resolved}catch{s=i}if(n="string"===typeof e&&i.toString()===s.toString()?e:encodeURI(s.toString(!0)),t?.allowContributedOpeners){const e="string"===typeof t?.allowContributedOpeners?t?.allowContributedOpeners:void 0;for(const t of this._externalOpeners){if(await t.openExternal(n,{sourceUri:i,preferredOpenerId:e},at.XO.None))return!0}}return this._defaultExternalOpener.openExternal(n,{sourceUri:i},at.XO.None)}dispose(){this._validators.clear()}};Pi=Ii([Oi(0,g.T),Oi(1,St.d)],Pi);var Fi=i(10920),Ui=i(10154),Hi=i(30707),Bi=i(37550),Wi=i(16363),Vi=i(71597),zi=i(51467),Gi=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ji=function(e,t){return function(i,s){t(i,s,e)}};let Ki=class extends c.jG{constructor(e,t){super(),this.quickInputService=e,this.instantiationService=t,this.registry=Rt.O.as(Vi.Fd.Quickaccess),this.mapProviderToDescriptor=new Map,this.lastAcceptedPickerValues=new Map,this.visibleQuickAccess=void 0}show(e="",t){this.doShowOrPick(e,!1,t)}doShowOrPick(e,t,i){const[s,n]=this.getOrInstantiateProvider(e,i?.enabledProviderPrefixes),r=this.visibleQuickAccess,o=r?.descriptor;if(r&&n&&o===n)return e===n.prefix||i?.preserveValue||(r.picker.value=e),void this.adjustValueSelection(r.picker,n,i);if(n&&!i?.preserveValue){let t;if(r&&o&&o!==n){const e=r.value.substr(o.prefix.length);e&&(t=`${n.prefix}${e}`)}if(!t){const e=s?.defaultFilterValue;e===Vi.aJ.LAST?t=this.lastAcceptedPickerValues.get(n):"string"===typeof e&&(t=`${n.prefix}${e}`)}"string"===typeof t&&(e=t)}const a=r?.picker?.valueSelection,l=r?.picker?.value,h=new c.Cm,d=h.add(this.quickInputService.createQuickPick({useSeparators:!0}));let u;d.value=e,this.adjustValueSelection(d,n,i),d.placeholder=i?.placeholder??n?.placeholder,d.quickNavigate=i?.quickNavigateConfiguration,d.hideInput=!!d.quickNavigate&&!r,("number"===typeof i?.itemActivation||i?.quickNavigateConfiguration)&&(d.itemActivation=i?.itemActivation??zi.C1.SECOND),d.contextKey=n?.contextKey,d.filterValue=e=>e.substring(n?n.prefix.length:0),t&&(u=new m.Zv,h.add(Q.Jh.once(d.onWillAccept)((e=>{e.veto(),d.hide()})))),h.add(this.registerPickerListeners(d,s,n,e,i));const g=h.add(new at.Qi);return s&&h.add(s.provide(d,g.token,i?.providerOptions)),Q.Jh.once(d.onDidHide)((()=>{0===d.selectedItems.length&&g.cancel(),h.dispose(),u?.complete(d.selectedItems.slice(0))})),d.show(),a&&l===e&&(d.valueSelection=a),t?u?.p:void 0}adjustValueSelection(e,t,i){let s;s=i?.preserveValue?[e.value.length,e.value.length]:[t?.prefix.length??0,e.value.length],e.valueSelection=s}registerPickerListeners(e,t,i,s,n){const r=new c.Cm,o=this.visibleQuickAccess={picker:e,descriptor:i,value:s};return r.add((0,c.s)((()=>{o===this.visibleQuickAccess&&(this.visibleQuickAccess=void 0)}))),r.add(e.onDidChangeValue((e=>{const[i]=this.getOrInstantiateProvider(e,n?.enabledProviderPrefixes);i!==t?this.show(e,{enabledProviderPrefixes:n?.enabledProviderPrefixes,preserveValue:!0,providerOptions:n?.providerOptions}):o.value=e}))),i&&r.add(e.onDidAccept((()=>{this.lastAcceptedPickerValues.set(i,e.value)}))),r}getOrInstantiateProvider(e,t){const i=this.registry.getQuickAccessProvider(e);if(!i||t&&!t?.includes(i.prefix))return[void 0,void 0];let s=this.mapProviderToDescriptor.get(i);return s||(s=this.instantiationService.createInstance(i.ctor),this.mapProviderToDescriptor.set(i,s)),[s,i]}};Ki=Gi([ji(0,zi.GK),ji(1,ae._Y)],Ki);var Yi=i(35315),qi=i(56245),$i=i(20370),Qi=i(96032),Xi=i(58694),Zi=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};class Ji{constructor(e){this.nodes=e}toString(){return this.nodes.map((e=>"string"===typeof e?e:e.label)).join("")}}Zi([Xi.B],Ji.prototype,"toString",null);const es=/\[([^\]]+)\]\(((?:https?:\/\/|command:|file:)[^\)\s]+)(?: (["'])(.+?)(\3))?\)/gi;const ts={},is=new Qi.n("quick-input-button-icon-");function ss(e,t,i){let s=e.iconClass||function(e){if(!e)return;let t;const i=e.dark.toString();return ts[i]?t=ts[i]:(t=is.nextId(),U.Wt(`.${t}, .hc-light .${t}`,`background-image: ${U.Tf(e.light||e.dark)}`),U.Wt(`.vs-dark .${t}, .hc-black .${t}`,`background-image: ${U.Tf(e.dark)}`),ts[i]=t),t}(e.iconPath);return e.alwaysVisible&&(s=s?`${s} always-visible`:"always-visible"),{id:t,label:"",tooltip:e.tooltip||"",class:s,enabled:!0,run:i}}function ns(e,t,i){U.Ln(t);const s=function(e){const t=[];let i,s=0;for(;i=es.exec(e);){i.index-s>0&&t.push(e.substring(s,i.index));const[,n,r,,o]=i;o?t.push({label:n,href:r,title:o}):t.push({label:n,href:r}),s=i.index+i[0].length}return s{U.sd(e)&&U.fs.stop(e,!0),i.callback(r.href)},a=i.disposables.add(new qi.f(s,U.Bx.CLICK)).event,c=i.disposables.add(new qi.f(s,U.Bx.KEY_DOWN)).event,l=Q.Jh.chain(c,(e=>e.filter((e=>{const t=new Xe.Z(e);return t.equals(10)||t.equals(3)}))));i.disposables.add(ai.q.addTarget(s));const h=i.disposables.add(new qi.f(s,ai.B.Tap)).event;Q.Jh.any(a,h,l)(o,null,i.disposables),t.appendChild(s)}}var rs=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},os=function(e,t){return function(i,s){t(i,s,e)}};const as="inQuickInput",cs=new ie.N1(as,!1,(0,b.kg)("inQuickInput","Whether keyboard focus is inside the quick input control")),ls=ie.M$.has(as),hs="quickInputType",ds=new ie.N1(hs,void 0,(0,b.kg)("quickInputType","The type of the currently visible quick input")),us="cursorAtEndOfQuickInputBox",gs=new ie.N1(us,!1,(0,b.kg)("cursorAtEndOfQuickInputBox","Whether the cursor in the quick input is at the end of the input box")),ps=ie.M$.has(us),ms={iconClass:gi.L.asClassName(di.W.quickInputBack),tooltip:(0,b.kg)("quickInput.back","Back"),handle:-1};class fs extends c.jG{static{this.noPromptMessage=(0,b.kg)("inputModeEntry","Press 'Enter' to confirm your input or 'Escape' to cancel")}constructor(e){super(),this.ui=e,this._widgetUpdated=!1,this.visible=!1,this._enabled=!0,this._busy=!1,this._ignoreFocusOut=!1,this._leftButtons=[],this._rightButtons=[],this._inlineButtons=[],this.buttonsUpdated=!1,this._toggles=[],this.togglesUpdated=!1,this.noValidationMessage=fs.noPromptMessage,this._severity=ge.A.Ignore,this.onDidTriggerButtonEmitter=this._register(new Q.vl),this.onDidHideEmitter=this._register(new Q.vl),this.onWillHideEmitter=this._register(new Q.vl),this.onDisposeEmitter=this._register(new Q.vl),this.visibleDisposables=this._register(new c.Cm),this.onDidHide=this.onDidHideEmitter.event}get title(){return this._title}set title(e){this._title=e,this.update()}get description(){return this._description}set description(e){this._description=e,this.update()}get step(){return this._steps}set step(e){this._steps=e,this.update()}get totalSteps(){return this._totalSteps}set totalSteps(e){this._totalSteps=e,this.update()}get enabled(){return this._enabled}set enabled(e){this._enabled=e,this.update()}get contextKey(){return this._contextKey}set contextKey(e){this._contextKey=e,this.update()}get busy(){return this._busy}set busy(e){this._busy=e,this.update()}get ignoreFocusOut(){return this._ignoreFocusOut}set ignoreFocusOut(e){const t=this._ignoreFocusOut!==e&&!We.un;this._ignoreFocusOut=e&&!We.un,t&&this.update()}get titleButtons(){return this._leftButtons.length?[...this._leftButtons,this._rightButtons]:this._rightButtons}get buttons(){return[...this._leftButtons,...this._rightButtons,...this._inlineButtons]}set buttons(e){this._leftButtons=e.filter((e=>e===ms)),this._rightButtons=e.filter((e=>e!==ms&&e.location!==zi.dH.Inline)),this._inlineButtons=e.filter((e=>e.location===zi.dH.Inline)),this.buttonsUpdated=!0,this.update()}get toggles(){return this._toggles}set toggles(e){this._toggles=e??[],this.togglesUpdated=!0,this.update()}get validationMessage(){return this._validationMessage}set validationMessage(e){this._validationMessage=e,this.update()}get severity(){return this._severity}set severity(e){this._severity=e,this.update()}show(){this.visible||(this.visibleDisposables.add(this.ui.onDidTriggerButton((e=>{-1!==this.buttons.indexOf(e)&&this.onDidTriggerButtonEmitter.fire(e)}))),this.ui.show(this),this.visible=!0,this._lastValidationMessage=void 0,this._lastSeverity=void 0,this.buttons.length&&(this.buttonsUpdated=!0),this.toggles.length&&(this.togglesUpdated=!0),this.update())}hide(){this.visible&&this.ui.hide()}didHide(e=zi.kF.Other){this.visible=!1,this.visibleDisposables.clear(),this.onDidHideEmitter.fire({reason:e})}willHide(e=zi.kF.Other){this.onWillHideEmitter.fire({reason:e})}update(){if(!this.visible)return;const e=this.getTitle();e&&this.ui.title.textContent!==e?this.ui.title.textContent=e:e||" "===this.ui.title.innerHTML||(this.ui.title.innerText="\xa0");const t=this.getDescription();if(this.ui.description1.textContent!==t&&(this.ui.description1.textContent=t),this.ui.description2.textContent!==t&&(this.ui.description2.textContent=t),this._widgetUpdated&&(this._widgetUpdated=!1,this._widget?U.Ln(this.ui.widget,this._widget):U.Ln(this.ui.widget)),this.busy&&!this.busyDelay&&(this.busyDelay=new m.pc,this.busyDelay.setIfNotSet((()=>{this.visible&&this.ui.progressBar.infinite()}),800)),!this.busy&&this.busyDelay&&(this.ui.progressBar.stop(),this.busyDelay.cancel(),this.busyDelay=void 0),this.buttonsUpdated){this.buttonsUpdated=!1,this.ui.leftActionBar.clear();const e=this._leftButtons.map(((e,t)=>ss(e,`id-${t}`,(async()=>this.onDidTriggerButtonEmitter.fire(e)))));this.ui.leftActionBar.push(e,{icon:!0,label:!1}),this.ui.rightActionBar.clear();const t=this._rightButtons.map(((e,t)=>ss(e,`id-${t}`,(async()=>this.onDidTriggerButtonEmitter.fire(e)))));this.ui.rightActionBar.push(t,{icon:!0,label:!1}),this.ui.inlineActionBar.clear();const i=this._inlineButtons.map(((e,t)=>ss(e,`id-${t}`,(async()=>this.onDidTriggerButtonEmitter.fire(e)))));this.ui.inlineActionBar.push(i,{icon:!0,label:!1})}if(this.togglesUpdated){this.togglesUpdated=!1;const e=this.toggles?.filter((e=>e instanceof Yi.l))??[];this.ui.inputBox.toggles=e}this.ui.ignoreFocusOut=this.ignoreFocusOut,this.ui.setEnabled(this.enabled),this.ui.setContextKey(this.contextKey);const i=this.validationMessage||this.noValidationMessage;this._lastValidationMessage!==i&&(this._lastValidationMessage=i,U.Ln(this.ui.message),ns(i,this.ui.message,{callback:e=>{this.ui.linkOpenerDelegate(e)},disposables:this.visibleDisposables})),this._lastSeverity!==this.severity&&(this._lastSeverity=this.severity,this.showMessageDecoration(this.severity))}getTitle(){return this.title&&this.step?`${this.title} (${this.getSteps()})`:this.title?this.title:this.step?this.getSteps():""}getDescription(){return this.description||""}getSteps(){return this.step&&this.totalSteps?(0,b.kg)("quickInput.steps","{0}/{1}",this.step,this.totalSteps):this.step?String(this.step):""}showMessageDecoration(e){if(this.ui.inputBox.showDecoration(e),e!==ge.A.Ignore){const t=this.ui.inputBox.stylesForType(e);this.ui.message.style.color=t.foreground?`${t.foreground}`:"",this.ui.message.style.backgroundColor=t.background?`${t.background}`:"",this.ui.message.style.border=t.border?`1px solid ${t.border}`:"",this.ui.message.style.marginBottom="-2px"}else this.ui.message.style.color="",this.ui.message.style.backgroundColor="",this.ui.message.style.border="",this.ui.message.style.marginBottom=""}dispose(){this.hide(),this.onDisposeEmitter.fire(),super.dispose()}}class _s extends fs{constructor(){super(...arguments),this._value="",this.onDidChangeValueEmitter=this._register(new Q.vl),this.onWillAcceptEmitter=this._register(new Q.vl),this.onDidAcceptEmitter=this._register(new Q.vl),this.onDidCustomEmitter=this._register(new Q.vl),this._items=[],this.itemsUpdated=!1,this._canSelectMany=!1,this._canAcceptInBackground=!1,this._matchOnDescription=!1,this._matchOnDetail=!1,this._matchOnLabel=!0,this._matchOnLabelMode="fuzzy",this._sortByLabel=!0,this._keepScrollPosition=!1,this._itemActivation=zi.C1.FIRST,this._activeItems=[],this.activeItemsUpdated=!1,this.activeItemsToConfirm=[],this.onDidChangeActiveEmitter=this._register(new Q.vl),this._selectedItems=[],this.selectedItemsUpdated=!1,this.selectedItemsToConfirm=[],this.onDidChangeSelectionEmitter=this._register(new Q.vl),this.onDidTriggerItemButtonEmitter=this._register(new Q.vl),this.onDidTriggerSeparatorButtonEmitter=this._register(new Q.vl),this.valueSelectionUpdated=!0,this._ok="default",this._customButton=!1,this._focusEventBufferer=new Q.at,this.type="quickPick",this.filterValue=e=>e,this.onDidChangeValue=this.onDidChangeValueEmitter.event,this.onWillAccept=this.onWillAcceptEmitter.event,this.onDidAccept=this.onDidAcceptEmitter.event,this.onDidChangeActive=this.onDidChangeActiveEmitter.event,this.onDidChangeSelection=this.onDidChangeSelectionEmitter.event,this.onDidTriggerItemButton=this.onDidTriggerItemButtonEmitter.event,this.onDidTriggerSeparatorButton=this.onDidTriggerSeparatorButtonEmitter.event}static{this.DEFAULT_ARIA_LABEL=(0,b.kg)("quickInputBox.ariaLabel","Type to narrow down results.")}get quickNavigate(){return this._quickNavigate}set quickNavigate(e){this._quickNavigate=e,this.update()}get value(){return this._value}set value(e){this.doSetValue(e)}doSetValue(e,t){if(this._value!==e){if(this._value=e,t||this.update(),this.visible){this.ui.list.filter(this.filterValue(this._value))&&this.trySelectFirst()}this.onDidChangeValueEmitter.fire(this._value)}}set ariaLabel(e){this._ariaLabel=e,this.update()}get ariaLabel(){return this._ariaLabel}get placeholder(){return this._placeholder}set placeholder(e){this._placeholder=e,this.update()}get items(){return this._items}get scrollTop(){return this.ui.list.scrollTop}set scrollTop(e){this.ui.list.scrollTop=e}set items(e){this._items=e,this.itemsUpdated=!0,this.update()}get canSelectMany(){return this._canSelectMany}set canSelectMany(e){this._canSelectMany=e,this.update()}get canAcceptInBackground(){return this._canAcceptInBackground}set canAcceptInBackground(e){this._canAcceptInBackground=e}get matchOnDescription(){return this._matchOnDescription}set matchOnDescription(e){this._matchOnDescription=e,this.update()}get matchOnDetail(){return this._matchOnDetail}set matchOnDetail(e){this._matchOnDetail=e,this.update()}get matchOnLabel(){return this._matchOnLabel}set matchOnLabel(e){this._matchOnLabel=e,this.update()}get matchOnLabelMode(){return this._matchOnLabelMode}set matchOnLabelMode(e){this._matchOnLabelMode=e,this.update()}get sortByLabel(){return this._sortByLabel}set sortByLabel(e){this._sortByLabel=e,this.update()}get keepScrollPosition(){return this._keepScrollPosition}set keepScrollPosition(e){this._keepScrollPosition=e}get itemActivation(){return this._itemActivation}set itemActivation(e){this._itemActivation=e}get activeItems(){return this._activeItems}set activeItems(e){this._activeItems=e,this.activeItemsUpdated=!0,this.update()}get selectedItems(){return this._selectedItems}set selectedItems(e){this._selectedItems=e,this.selectedItemsUpdated=!0,this.update()}get keyMods(){return this._quickNavigate?zi.Ym:this.ui.keyMods}get valueSelection(){const e=this.ui.inputBox.getSelection();if(e)return[e.start,e.end]}set valueSelection(e){this._valueSelection=e,this.valueSelectionUpdated=!0,this.update()}get customButton(){return this._customButton}set customButton(e){this._customButton=e,this.update()}get customLabel(){return this._customButtonLabel}set customLabel(e){this._customButtonLabel=e,this.update()}get customHover(){return this._customButtonHover}set customHover(e){this._customButtonHover=e,this.update()}get ok(){return this._ok}set ok(e){this._ok=e,this.update()}get hideInput(){return!!this._hideInput}set hideInput(e){this._hideInput=e,this.update()}trySelectFirst(){this.canSelectMany||this.ui.list.focus(zi.Fp.First)}show(){this.visible||(this.visibleDisposables.add(this.ui.inputBox.onDidChange((e=>{this.doSetValue(e,!0)}))),this.visibleDisposables.add(this.ui.onDidAccept((()=>{this.canSelectMany?this.ui.list.getCheckedElements().length||(this._selectedItems=[],this.onDidChangeSelectionEmitter.fire(this.selectedItems)):this.activeItems[0]&&(this._selectedItems=[this.activeItems[0]],this.onDidChangeSelectionEmitter.fire(this.selectedItems)),this.handleAccept(!1)}))),this.visibleDisposables.add(this.ui.onDidCustom((()=>{this.onDidCustomEmitter.fire()}))),this.visibleDisposables.add(this._focusEventBufferer.wrapEvent(this.ui.list.onDidChangeFocus,((e,t)=>t))((e=>{this.activeItemsUpdated||this.activeItemsToConfirm!==this._activeItems&&(0,E.aI)(e,this._activeItems,((e,t)=>e===t))||(this._activeItems=e,this.onDidChangeActiveEmitter.fire(e))}))),this.visibleDisposables.add(this.ui.list.onDidChangeSelection((({items:e,event:t})=>{this.canSelectMany?e.length&&this.ui.list.setSelectedElements([]):this.selectedItemsToConfirm!==this._selectedItems&&(0,E.aI)(e,this._selectedItems,((e,t)=>e===t))||(this._selectedItems=e,this.onDidChangeSelectionEmitter.fire(e),e.length&&this.handleAccept(U.Er(t)&&1===t.button))}))),this.visibleDisposables.add(this.ui.list.onChangedCheckedElements((e=>{this.canSelectMany&&this.visible&&(this.selectedItemsToConfirm!==this._selectedItems&&(0,E.aI)(e,this._selectedItems,((e,t)=>e===t))||(this._selectedItems=e,this.onDidChangeSelectionEmitter.fire(e)))}))),this.visibleDisposables.add(this.ui.list.onButtonTriggered((e=>this.onDidTriggerItemButtonEmitter.fire(e)))),this.visibleDisposables.add(this.ui.list.onSeparatorButtonTriggered((e=>this.onDidTriggerSeparatorButtonEmitter.fire(e)))),this.visibleDisposables.add(this.registerQuickNavigation()),this.valueSelectionUpdated=!0),super.show()}handleAccept(e){let t=!1;this.onWillAcceptEmitter.fire({veto:()=>t=!0}),t||this.onDidAcceptEmitter.fire({inBackground:e})}registerQuickNavigation(){return U.ko(this.ui.container,U.Bx.KEY_UP,(e=>{if(this.canSelectMany||!this._quickNavigate)return;const t=new Xe.Z(e),i=t.keyCode;this._quickNavigate.keybindings.some((e=>{const s=e.getChords();return!(s.length>1)&&(s[0].shiftKey&&4===i?!(t.ctrlKey||t.altKey||t.metaKey):!(!s[0].altKey||6!==i)||(!(!s[0].ctrlKey||5!==i)||!(!s[0].metaKey||57!==i)))}))&&(this.activeItems[0]&&(this._selectedItems=[this.activeItems[0]],this.onDidChangeSelectionEmitter.fire(this.selectedItems),this.handleAccept(!1)),this._quickNavigate=void 0)}))}update(){if(!this.visible)return;const e=this.keepScrollPosition?this.scrollTop:0,t=!!this.description,i={title:!!this.title||!!this.step||!!this.titleButtons.length,description:t,checkAll:this.canSelectMany&&!this._hideCheckAll,checkBox:this.canSelectMany,inputBox:!this._hideInput,progressBar:!this._hideInput||t,visibleCount:!0,count:this.canSelectMany&&!this._hideCountBadge,ok:"default"===this.ok?this.canSelectMany:this.ok,list:!0,message:!!this.validationMessage,customButton:this.customButton};this.ui.setVisibilities(i),super.update(),this.ui.inputBox.value!==this.value&&(this.ui.inputBox.value=this.value),this.valueSelectionUpdated&&(this.valueSelectionUpdated=!1,this.ui.inputBox.select(this._valueSelection&&{start:this._valueSelection[0],end:this._valueSelection[1]})),this.ui.inputBox.placeholder!==(this.placeholder||"")&&(this.ui.inputBox.placeholder=this.placeholder||"");let s=this.ariaLabel;!s&&i.inputBox&&(s=this.placeholder||_s.DEFAULT_ARIA_LABEL,this.title&&(s+=` - ${this.title}`)),this.ui.list.ariaLabel!==s&&(this.ui.list.ariaLabel=s??null),this.ui.list.matchOnDescription=this.matchOnDescription,this.ui.list.matchOnDetail=this.matchOnDetail,this.ui.list.matchOnLabel=this.matchOnLabel,this.ui.list.matchOnLabelMode=this.matchOnLabelMode,this.ui.list.sortByLabel=this.sortByLabel,this.itemsUpdated&&(this.itemsUpdated=!1,this._focusEventBufferer.bufferEvents((()=>{switch(this.ui.list.setElements(this.items),this.ui.list.shouldLoop=!this.canSelectMany,this.ui.list.filter(this.filterValue(this.ui.inputBox.value)),this._itemActivation){case zi.C1.NONE:this._itemActivation=zi.C1.FIRST;break;case zi.C1.SECOND:this.ui.list.focus(zi.Fp.Second),this._itemActivation=zi.C1.FIRST;break;case zi.C1.LAST:this.ui.list.focus(zi.Fp.Last),this._itemActivation=zi.C1.FIRST;break;default:this.trySelectFirst()}}))),this.ui.container.classList.contains("show-checkboxes")!==!!this.canSelectMany&&(this.canSelectMany?this.ui.list.clearFocus():this.trySelectFirst()),this.activeItemsUpdated&&(this.activeItemsUpdated=!1,this.activeItemsToConfirm=this._activeItems,this.ui.list.setFocusedElements(this.activeItems),this.activeItemsToConfirm===this._activeItems&&(this.activeItemsToConfirm=null)),this.selectedItemsUpdated&&(this.selectedItemsUpdated=!1,this.selectedItemsToConfirm=this._selectedItems,this.canSelectMany?this.ui.list.setCheckedElements(this.selectedItems):this.ui.list.setSelectedElements(this.selectedItems),this.selectedItemsToConfirm===this._selectedItems&&(this.selectedItemsToConfirm=null)),this.ui.customButton.label=this.customLabel||"",this.ui.customButton.element.title=this.customHover||"",i.inputBox||(this.ui.list.domFocus(),this.canSelectMany&&this.ui.list.focus(zi.Fp.First)),this.keepScrollPosition&&(this.scrollTop=e)}focus(e){this.ui.list.focus(e),this.canSelectMany&&this.ui.list.domFocus()}accept(e){e&&!this._canAcceptInBackground||this.activeItems[0]&&(this._selectedItems=[this.activeItems[0]],this.onDidChangeSelectionEmitter.fire(this.selectedItems),this.handleAccept(e??!1))}}class vs extends fs{constructor(){super(...arguments),this._value="",this.valueSelectionUpdated=!0,this._password=!1,this.onDidValueChangeEmitter=this._register(new Q.vl),this.onDidAcceptEmitter=this._register(new Q.vl),this.type="inputBox",this.onDidChangeValue=this.onDidValueChangeEmitter.event,this.onDidAccept=this.onDidAcceptEmitter.event}get value(){return this._value}set value(e){this._value=e||"",this.update()}get placeholder(){return this._placeholder}set placeholder(e){this._placeholder=e,this.update()}get password(){return this._password}set password(e){this._password=e,this.update()}show(){this.visible||(this.visibleDisposables.add(this.ui.inputBox.onDidChange((e=>{e!==this.value&&(this._value=e,this.onDidValueChangeEmitter.fire(e))}))),this.visibleDisposables.add(this.ui.onDidAccept((()=>this.onDidAcceptEmitter.fire()))),this.valueSelectionUpdated=!0),super.show()}update(){if(!this.visible)return;this.ui.container.classList.remove("hidden-input");const e={title:!!this.title||!!this.step||!!this.titleButtons.length,description:!!this.description||!!this.step,inputBox:!0,message:!0,progressBar:!0};this.ui.setVisibilities(e),super.update(),this.ui.inputBox.value!==this.value&&(this.ui.inputBox.value=this.value),this.valueSelectionUpdated&&(this.valueSelectionUpdated=!1,this.ui.inputBox.select(this._valueSelection&&{start:this._valueSelection[0],end:this._valueSelection[1]})),this.ui.inputBox.placeholder!==(this.placeholder||"")&&(this.ui.inputBox.placeholder=this.placeholder||""),this.ui.inputBox.password!==this.password&&(this.ui.inputBox.password=this.password)}}let Cs=class extends Ie.fO{constructor(e,t){super("element",!1,(e=>this.getOverrideOptions(e)),e,t)}getOverrideOptions(e){return{persistence:{hideOnKeyDown:!1},appearance:{showHoverHint:(U.sb(e.content)?e.content.textContent??"":"string"===typeof e.content?e.content:e.content.value).includes("\n"),skipFadeInAnimation:!0}}}};Cs=rs([os(0,Me.pG),os(1,Ie.TN)],Cs);var Es=i(62890),bs=i(3828);const Ss="done",ys="active",ws="infinite",Rs="infinite-long-running",Ls="discrete";class Ts extends c.jG{static{this.LONG_RUNNING_INFINITE_THRESHOLD=1e4}constructor(e,t){super(),this.progressSignal=this._register(new c.HE),this.workedVal=0,this.showDelayedScheduler=this._register(new m.uC((()=>(0,U.WU)(this.element)),0)),this.longRunningScheduler=this._register(new m.uC((()=>this.infiniteLongRunning()),Ts.LONG_RUNNING_INFINITE_THRESHOLD)),this.create(e,t)}create(e,t){this.element=document.createElement("div"),this.element.classList.add("monaco-progress-container"),this.element.setAttribute("role","progressbar"),this.element.setAttribute("aria-valuemin","0"),e.appendChild(this.element),this.bit=document.createElement("div"),this.bit.classList.add("progress-bit"),this.bit.style.backgroundColor=t?.progressBarBackground||"#0E70C0",this.element.appendChild(this.bit)}off(){this.bit.style.width="inherit",this.bit.style.opacity="1",this.element.classList.remove(ys,ws,Rs,Ls),this.workedVal=0,this.totalWork=void 0,this.longRunningScheduler.cancel(),this.progressSignal.clear()}stop(){return this.doDone(!1)}doDone(e){return this.element.classList.add(Ss),this.element.classList.contains(ws)?(this.bit.style.opacity="0",e?setTimeout((()=>this.off()),200):this.off()):(this.bit.style.width="inherit",e?setTimeout((()=>this.off()),200):this.off()),this}infinite(){return this.bit.style.width="2%",this.bit.style.opacity="1",this.element.classList.remove(Ls,Ss,Rs),this.element.classList.add(ys,ws),this.longRunningScheduler.schedule(),this}infiniteLongRunning(){this.element.classList.add(Rs)}getContainer(){return this.element}}var xs=i(88443);const ks=U.$;class As extends c.jG{constructor(e,t,i){super(),this.parent=e,this.onKeyDown=e=>U.b2(this.findInput.inputBox.inputElement,U.Bx.KEY_DOWN,e),this.onDidChange=e=>this.findInput.onDidChange(e),this.container=U.BC(this.parent,ks(".quick-input-box")),this.findInput=this._register(new xs.c(this.container,void 0,{label:"",inputBoxStyles:t,toggleStyles:i}));const s=this.findInput.inputBox.inputElement;s.role="combobox",s.ariaHasPopup="menu",s.ariaAutoComplete="list",s.ariaExpanded="true"}get value(){return this.findInput.getValue()}set value(e){this.findInput.setValue(e)}select(e=null){this.findInput.inputBox.select(e)}getSelection(){return this.findInput.inputBox.getSelection()}isSelectionAtEnd(){return this.findInput.inputBox.isSelectionAtEnd()}get placeholder(){return this.findInput.inputBox.inputElement.getAttribute("placeholder")||""}set placeholder(e){this.findInput.inputBox.setPlaceHolder(e)}get password(){return"password"===this.findInput.inputBox.inputElement.type}set password(e){this.findInput.inputBox.inputElement.type=e?"password":"text"}set enabled(e){this.findInput.inputBox.inputElement.toggleAttribute("readonly",!e)}set toggles(e){this.findInput.setAdditionalToggles(e)}setAttribute(e,t){this.findInput.inputBox.inputElement.setAttribute(e,t)}showDecoration(e){e===ge.A.Ignore?this.findInput.clearMessage():this.findInput.showMessage({type:e===ge.A.Info?1:e===ge.A.Warning?2:3,content:""})}stylesForType(e){return this.findInput.inputBox.stylesForType(e===ge.A.Info?1:e===ge.A.Warning?2:3)}setFocus(){this.findInput.focus()}layout(){this.findInput.inputBox.layout()}}var Ns=i(36584),Is=i(21852),Os=i(47625),Ds=i(86723),Ms=i(91090);const Ps=new Ms.d((()=>{const e=new Intl.Collator(void 0,{numeric:!0,sensitivity:"base"});return{collator:e,collatorIsNumeric:e.resolvedOptions().numeric}}));new Ms.d((()=>({collator:new Intl.Collator(void 0,{numeric:!0})}))),new Ms.d((()=>({collator:new Intl.Collator(void 0,{numeric:!0,sensitivity:"accent"})})));function Fs(e,t,i){const s=e.toLowerCase(),n=t.toLowerCase(),r=function(e,t,i){const s=e.toLowerCase(),n=t.toLowerCase(),r=s.startsWith(i),o=n.startsWith(i);if(r!==o)return r?-1:1;if(r&&o){if(s.lengthn.length)return 1}return 0}(e,t,i);if(r)return r;const o=s.endsWith(i);if(o!==n.endsWith(i))return o?-1:1;const a=function(e,t){const i=e||"",s=t||"",n=Ps.value.collator.compare(i,s);return Ps.value.collatorIsNumeric&&0===n&&i!==s?i=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Vs=function(e,t){return function(i,s){t(i,s,e)}};const zs=U.$;class Gs{constructor(e,t,i){this.index=e,this.hasCheckbox=t,this._hidden=!1,this._init=new Ms.d((()=>{const e=i.label??"",t=(0,pi._k)(e).text.trim(),s=i.ariaLabel||[e,this.saneDescription,this.saneDetail].map((e=>(0,pi.R$)(e))).filter((e=>!!e)).join(", ");return{saneLabel:e,saneSortLabel:t,saneAriaLabel:s}})),this._saneDescription=i.description,this._saneTooltip=i.tooltip}get saneLabel(){return this._init.value.saneLabel}get saneSortLabel(){return this._init.value.saneSortLabel}get saneAriaLabel(){return this._init.value.saneAriaLabel}get element(){return this._element}set element(e){this._element=e}get hidden(){return this._hidden}set hidden(e){this._hidden=e}get saneDescription(){return this._saneDescription}set saneDescription(e){this._saneDescription=e}get saneDetail(){return this._saneDetail}set saneDetail(e){this._saneDetail=e}get saneTooltip(){return this._saneTooltip}set saneTooltip(e){this._saneTooltip=e}get labelHighlights(){return this._labelHighlights}set labelHighlights(e){this._labelHighlights=e}get descriptionHighlights(){return this._descriptionHighlights}set descriptionHighlights(e){this._descriptionHighlights=e}get detailHighlights(){return this._detailHighlights}set detailHighlights(e){this._detailHighlights=e}}class js extends Gs{constructor(e,t,i,s,n,r){super(e,t,n),this.fireButtonTriggered=i,this._onChecked=s,this.item=n,this._separator=r,this._checked=!1,this.onChecked=t?Q.Jh.map(Q.Jh.filter(this._onChecked.event,(e=>e.element===this)),(e=>e.checked)):Q.Jh.None,this._saneDetail=n.detail,this._labelHighlights=n.highlights?.label,this._descriptionHighlights=n.highlights?.description,this._detailHighlights=n.highlights?.detail}get separator(){return this._separator}set separator(e){this._separator=e}get checked(){return this._checked}set checked(e){e!==this._checked&&(this._checked=e,this._onChecked.fire({element:this,checked:e}))}get checkboxDisabled(){return!!this.item.disabled}}var Ks;!function(e){e[e.NONE=0]="NONE",e[e.MOUSE_HOVER=1]="MOUSE_HOVER",e[e.ACTIVE_ITEM=2]="ACTIVE_ITEM"}(Ks||(Ks={}));class Ys extends Gs{constructor(e,t,i){super(e,!1,i),this.fireSeparatorButtonTriggered=t,this.separator=i,this.children=new Array,this.focusInsideSeparator=Ks.NONE}}class qs{getHeight(e){return e instanceof Ys?30:e.saneDetail?44:22}getTemplateId(e){return e instanceof js?Xs.ID:Zs.ID}}class $s{getWidgetAriaLabel(){return(0,b.kg)("quickInput","Quick Input")}getAriaLabel(e){return e.separator?.label?`${e.saneAriaLabel}, ${e.separator.label}`:e.saneAriaLabel}getWidgetRole(){return"listbox"}getRole(e){return e.hasCheckbox?"checkbox":"option"}isChecked(e){if(e.hasCheckbox&&e instanceof js)return{get value(){return e.checked},onDidChange:t=>e.onChecked((()=>t()))}}}class Qs{constructor(e){this.hoverDelegate=e}renderTemplate(e){const t=Object.create(null);t.toDisposeElement=new c.Cm,t.toDisposeTemplate=new c.Cm,t.entry=U.BC(e,zs(".quick-input-list-entry"));const i=U.BC(t.entry,zs("label.quick-input-list-label"));t.toDisposeTemplate.add(U.b2(i,U.Bx.CLICK,(e=>{t.checkbox.offsetParent||e.preventDefault()}))),t.checkbox=U.BC(i,zs("input.quick-input-list-checkbox")),t.checkbox.type="checkbox";const s=U.BC(i,zs(".quick-input-list-rows")),n=U.BC(s,zs(".quick-input-list-row")),r=U.BC(s,zs(".quick-input-list-row"));t.label=new Is.s(n,{supportHighlights:!0,supportDescriptionHighlights:!0,supportIcons:!0,hoverDelegate:this.hoverDelegate}),t.toDisposeTemplate.add(t.label),t.icon=U.Hs(t.label.element,zs(".quick-input-list-icon"));const o=U.BC(n,zs(".quick-input-list-entry-keybinding"));t.keybinding=new Os.x(o,We.OS),t.toDisposeTemplate.add(t.keybinding);const a=U.BC(r,zs(".quick-input-list-label-meta"));return t.detail=new Is.s(a,{supportHighlights:!0,supportIcons:!0,hoverDelegate:this.hoverDelegate}),t.toDisposeTemplate.add(t.detail),t.separator=U.BC(t.entry,zs(".quick-input-list-separator")),t.actionBar=new ci.E(t.entry,this.hoverDelegate?{hoverDelegate:this.hoverDelegate}:void 0),t.actionBar.domNode.classList.add("quick-input-list-entry-action-bar"),t.toDisposeTemplate.add(t.actionBar),t}disposeTemplate(e){e.toDisposeElement.dispose(),e.toDisposeTemplate.dispose()}disposeElement(e,t,i){i.toDisposeElement.clear(),i.actionBar.clear()}}let Xs=class extends Qs{static{Us=this}static{this.ID="quickpickitem"}constructor(e,t){super(e),this.themeService=t,this._itemsWithSeparatorsFrequency=new Map}get templateId(){return Us.ID}renderTemplate(e){const t=super.renderTemplate(e);return t.toDisposeTemplate.add(U.b2(t.checkbox,U.Bx.CHANGE,(e=>{t.element.checked=t.checkbox.checked}))),t}renderElement(e,t,i){const s=e.element;i.element=s,s.element=i.entry??void 0;const n=s.item;i.checkbox.checked=s.checked,i.toDisposeElement.add(s.onChecked((e=>i.checkbox.checked=e))),i.checkbox.disabled=s.checkboxDisabled;const{labelHighlights:r,descriptionHighlights:o,detailHighlights:a}=s;if(n.iconPath){const e=(0,Ds.HD)(this.themeService.getColorTheme().type)?n.iconPath.dark:n.iconPath.light??n.iconPath.dark,t=h.r.revive(e);i.icon.className="quick-input-list-icon",i.icon.style.backgroundImage=U.Tf(t)}else i.icon.style.backgroundImage="",i.icon.className=n.iconClass?`quick-input-list-icon ${n.iconClass}`:"";let c;!s.saneTooltip&&s.saneDescription&&(c={markdown:{value:s.saneDescription,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDescription});const l={matches:r||[],descriptionTitle:c,descriptionMatches:o||[],labelEscapeNewLines:!0};if(l.extraClasses=n.iconClasses,l.italic=n.italic,l.strikethrough=n.strikethrough,i.entry.classList.remove("quick-input-list-separator-as-item"),i.label.setLabel(s.saneLabel,s.saneDescription,l),i.keybinding.set(n.keybinding),s.saneDetail){let e;s.saneTooltip||(e={markdown:{value:s.saneDetail,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDetail}),i.detail.element.style.display="",i.detail.setLabel(s.saneDetail,void 0,{matches:a,title:e,labelEscapeNewLines:!0})}else i.detail.element.style.display="none";s.separator?.label?(i.separator.textContent=s.separator.label,i.separator.style.display="",this.addItemWithSeparator(s)):i.separator.style.display="none",i.entry.classList.toggle("quick-input-list-separator-border",!!s.separator);const d=n.buttons;d&&d.length?(i.actionBar.push(d.map(((e,t)=>ss(e,`id-${t}`,(()=>s.fireButtonTriggered({button:e,item:s.item}))))),{icon:!0,label:!1}),i.entry.classList.add("has-actions")):i.entry.classList.remove("has-actions")}disposeElement(e,t,i){this.removeItemWithSeparator(e.element),super.disposeElement(e,t,i)}isItemWithSeparatorVisible(e){return this._itemsWithSeparatorsFrequency.has(e)}addItemWithSeparator(e){this._itemsWithSeparatorsFrequency.set(e,(this._itemsWithSeparatorsFrequency.get(e)||0)+1)}removeItemWithSeparator(e){const t=this._itemsWithSeparatorsFrequency.get(e)||0;t>1?this._itemsWithSeparatorsFrequency.set(e,t-1):this._itemsWithSeparatorsFrequency.delete(e)}};Xs=Us=Ws([Vs(1,Z.Gy)],Xs);class Zs extends Qs{constructor(){super(...arguments),this._visibleSeparatorsFrequency=new Map}static{this.ID="quickpickseparator"}get templateId(){return Zs.ID}get visibleSeparators(){return[...this._visibleSeparatorsFrequency.keys()]}isSeparatorVisible(e){return this._visibleSeparatorsFrequency.has(e)}renderTemplate(e){const t=super.renderTemplate(e);return t.checkbox.style.display="none",t}renderElement(e,t,i){const s=e.element;i.element=s,s.element=i.entry??void 0,s.element.classList.toggle("focus-inside",!!s.focusInsideSeparator);const n=s.separator,{labelHighlights:r,descriptionHighlights:o,detailHighlights:a}=s;let c;i.icon.style.backgroundImage="",i.icon.className="",!s.saneTooltip&&s.saneDescription&&(c={markdown:{value:s.saneDescription,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDescription});const l={matches:r||[],descriptionTitle:c,descriptionMatches:o||[],labelEscapeNewLines:!0};if(i.entry.classList.add("quick-input-list-separator-as-item"),i.label.setLabel(s.saneLabel,s.saneDescription,l),s.saneDetail){let e;s.saneTooltip||(e={markdown:{value:s.saneDetail,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDetail}),i.detail.element.style.display="",i.detail.setLabel(s.saneDetail,void 0,{matches:a,title:e,labelEscapeNewLines:!0})}else i.detail.element.style.display="none";i.separator.style.display="none",i.entry.classList.add("quick-input-list-separator-border");const h=n.buttons;h&&h.length?(i.actionBar.push(h.map(((e,t)=>ss(e,`id-${t}`,(()=>s.fireSeparatorButtonTriggered({button:e,separator:s.separator}))))),{icon:!0,label:!1}),i.entry.classList.add("has-actions")):i.entry.classList.remove("has-actions"),this.addSeparator(s)}disposeElement(e,t,i){this.removeSeparator(e.element),this.isSeparatorVisible(e.element)||e.element.element?.classList.remove("focus-inside"),super.disposeElement(e,t,i)}addSeparator(e){this._visibleSeparatorsFrequency.set(e,(this._visibleSeparatorsFrequency.get(e)||0)+1)}removeSeparator(e){const t=this._visibleSeparatorsFrequency.get(e)||0;t>1?this._visibleSeparatorsFrequency.set(e,t-1):this._visibleSeparatorsFrequency.delete(e)}}let Js=class extends c.jG{constructor(e,t,i,s,n,r){super(),this.parent=e,this.hoverDelegate=t,this.linkOpenerDelegate=i,this.accessibilityService=r,this._onKeyDown=new Q.vl,this._onLeave=new Q.vl,this.onLeave=this._onLeave.event,this._visibleCountObservable=(0,Bs.FY)("VisibleCount",0),this.onChangedVisibleCount=Q.Jh.fromObservable(this._visibleCountObservable,this._store),this._allVisibleCheckedObservable=(0,Bs.FY)("AllVisibleChecked",!1),this.onChangedAllVisibleChecked=Q.Jh.fromObservable(this._allVisibleCheckedObservable,this._store),this._checkedCountObservable=(0,Bs.FY)("CheckedCount",0),this.onChangedCheckedCount=Q.Jh.fromObservable(this._checkedCountObservable,this._store),this._checkedElementsObservable=(0,Bs.Zh)({equalsFn:E.aI},new Array),this.onChangedCheckedElements=Q.Jh.fromObservable(this._checkedElementsObservable,this._store),this._onButtonTriggered=new Q.vl,this.onButtonTriggered=this._onButtonTriggered.event,this._onSeparatorButtonTriggered=new Q.vl,this.onSeparatorButtonTriggered=this._onSeparatorButtonTriggered.event,this._elementChecked=new Q.vl,this._elementCheckedEventBufferer=new Q.at,this._hasCheckboxes=!1,this._inputElements=new Array,this._elementTree=new Array,this._itemElements=new Array,this._elementDisposable=this._register(new c.Cm),this._matchOnDescription=!1,this._matchOnDetail=!1,this._matchOnLabel=!0,this._matchOnLabelMode="fuzzy",this._sortByLabel=!0,this._shouldLoop=!0,this._container=U.BC(this.parent,zs(".quick-input-list")),this._separatorRenderer=new Zs(t),this._itemRenderer=n.createInstance(Xs,t),this._tree=this._register(n.createInstance(Ns.zL,"QuickInput",this._container,new qs,[this._itemRenderer,this._separatorRenderer],{filter:{filter:e=>e.hidden?0:e instanceof Ys?2:1},sorter:{compare:(e,t)=>{if(!this.sortByLabel||!this._lastQueryString)return 0;return function(e,t,i){const s=e.labelHighlights||[],n=t.labelHighlights||[];if(s.length&&!n.length)return-1;if(!s.length&&n.length)return 1;if(0===s.length&&0===n.length)return 0;return Fs(e.saneSortLabel,t.saneSortLabel,i)}(e,t,this._lastQueryString.toLowerCase())}},accessibilityProvider:new $s,setRowLineHeight:!1,multipleSelectionSupport:!1,hideTwistiesOfChildlessElements:!0,renderIndentGuides:Hs.KP.None,findWidgetEnabled:!1,indent:0,horizontalScrolling:!1,allowNonCollapsibleParents:!0,alwaysConsumeMouseWheel:!0})),this._tree.getHTMLElement().id=s,this._registerListeners()}get onDidChangeFocus(){return Q.Jh.map(this._tree.onDidChangeFocus,(e=>e.elements.filter((e=>e instanceof js)).map((e=>e.item))),this._store)}get onDidChangeSelection(){return Q.Jh.map(this._tree.onDidChangeSelection,(e=>({items:e.elements.filter((e=>e instanceof js)).map((e=>e.item)),event:e.browserEvent})),this._store)}get displayed(){return"none"!==this._container.style.display}set displayed(e){this._container.style.display=e?"":"none"}get scrollTop(){return this._tree.scrollTop}set scrollTop(e){this._tree.scrollTop=e}get ariaLabel(){return this._tree.ariaLabel}set ariaLabel(e){this._tree.ariaLabel=e??""}set enabled(e){this._tree.getHTMLElement().style.pointerEvents=e?"":"none"}get matchOnDescription(){return this._matchOnDescription}set matchOnDescription(e){this._matchOnDescription=e}get matchOnDetail(){return this._matchOnDetail}set matchOnDetail(e){this._matchOnDetail=e}get matchOnLabel(){return this._matchOnLabel}set matchOnLabel(e){this._matchOnLabel=e}get matchOnLabelMode(){return this._matchOnLabelMode}set matchOnLabelMode(e){this._matchOnLabelMode=e}get sortByLabel(){return this._sortByLabel}set sortByLabel(e){this._sortByLabel=e}get shouldLoop(){return this._shouldLoop}set shouldLoop(e){this._shouldLoop=e}_registerListeners(){this._registerOnKeyDown(),this._registerOnContainerClick(),this._registerOnMouseMiddleClick(),this._registerOnTreeModelChanged(),this._registerOnElementChecked(),this._registerOnContextMenu(),this._registerHoverListeners(),this._registerSelectionChangeListener(),this._registerSeparatorActionShowingListeners()}_registerOnKeyDown(){this._register(this._tree.onKeyDown((e=>{const t=new Xe.Z(e);if(10===t.keyCode)this.toggleCheckbox();this._onKeyDown.fire(t)})))}_registerOnContainerClick(){this._register(U.ko(this._container,U.Bx.CLICK,(e=>{(e.x||e.y)&&this._onLeave.fire()})))}_registerOnMouseMiddleClick(){this._register(U.ko(this._container,U.Bx.AUXCLICK,(e=>{1===e.button&&this._onLeave.fire()})))}_registerOnTreeModelChanged(){this._register(this._tree.onDidChangeModel((()=>{const e=this._itemElements.filter((e=>!e.hidden)).length;this._visibleCountObservable.set(e,void 0),this._hasCheckboxes&&this._updateCheckedObservables()})))}_registerOnElementChecked(){this._register(this._elementCheckedEventBufferer.wrapEvent(this._elementChecked.event,((e,t)=>t))((e=>this._updateCheckedObservables())))}_registerOnContextMenu(){this._register(this._tree.onContextMenu((e=>{e.element&&(e.browserEvent.preventDefault(),this._tree.setSelection([e.element]))})))}_registerHoverListeners(){const e=this._register(new m.Th(this.hoverDelegate.delay));this._register(this._tree.onMouseOver((async t=>{if(U.nY(t.browserEvent.target))e.cancel();else if(U.nY(t.browserEvent.relatedTarget)||!U.QX(t.browserEvent.relatedTarget,t.element?.element))try{await e.trigger((async()=>{t.element instanceof js&&this.showHover(t.element)}))}catch(t){if(!(0,v.MB)(t))throw t}}))),this._register(this._tree.onMouseOut((t=>{U.QX(t.browserEvent.relatedTarget,t.element?.element)||e.cancel()})))}_registerSeparatorActionShowingListeners(){this._register(this._tree.onDidChangeFocus((e=>{const t=e.elements[0]?this._tree.getParentElement(e.elements[0]):null;for(const i of this._separatorRenderer.visibleSeparators){const e=i===t;!!(i.focusInsideSeparator&Ks.ACTIVE_ITEM)!==e&&(e?i.focusInsideSeparator|=Ks.ACTIVE_ITEM:i.focusInsideSeparator&=~Ks.ACTIVE_ITEM,this._tree.rerender(i))}}))),this._register(this._tree.onMouseOver((e=>{const t=e.element?this._tree.getParentElement(e.element):null;for(const i of this._separatorRenderer.visibleSeparators){if(i!==t)continue;!!(i.focusInsideSeparator&Ks.MOUSE_HOVER)||(i.focusInsideSeparator|=Ks.MOUSE_HOVER,this._tree.rerender(i))}}))),this._register(this._tree.onMouseOut((e=>{const t=e.element?this._tree.getParentElement(e.element):null;for(const i of this._separatorRenderer.visibleSeparators){if(i!==t)continue;!!(i.focusInsideSeparator&Ks.MOUSE_HOVER)&&(i.focusInsideSeparator&=~Ks.MOUSE_HOVER,this._tree.rerender(i))}})))}_registerSelectionChangeListener(){this._register(this._tree.onDidChangeSelection((e=>{const t=e.elements.filter((e=>e instanceof js));t.length!==e.elements.length&&(1===e.elements.length&&e.elements[0]instanceof Ys&&(this._tree.setFocus([e.elements[0].children[0]]),this._tree.reveal(e.elements[0],0)),this._tree.setSelection(t))})))}setAllVisibleChecked(e){this._elementCheckedEventBufferer.bufferEvents((()=>{this._itemElements.forEach((t=>{t.hidden||t.checkboxDisabled||(t.checked=e)}))}))}setElements(e){let t;this._elementDisposable.clear(),this._lastQueryString=void 0,this._inputElements=e,this._hasCheckboxes=this.parent.classList.contains("show-checkboxes"),this._itemElements=new Array,this._elementTree=e.reduce(((i,s,n)=>{let r;if("separator"===s.type){if(!s.buttons)return i;t=new Ys(n,(e=>this._onSeparatorButtonTriggered.fire(e)),s),r=t}else{const o=n>0?e[n-1]:void 0;let a;o&&"separator"===o.type&&!o.buttons&&(t=void 0,a=o);const c=new js(n,this._hasCheckboxes,(e=>this._onButtonTriggered.fire(e)),this._elementChecked,s,a);if(this._itemElements.push(c),t)return t.children.push(c),i;r=c}return i.push(r),i}),new Array),this._setElementsToTree(this._elementTree),this.accessibilityService.isScreenReaderOptimized()&&setTimeout((()=>{const e=this._tree.getHTMLElement().querySelector(".monaco-list-row.focused"),t=e?.parentNode;if(e&&t){const i=e.nextSibling;e.remove(),t.insertBefore(e,i)}}),0)}setFocusedElements(e){const t=e.map((e=>this._itemElements.find((t=>t.item===e)))).filter((e=>!!e)).filter((e=>!e.hidden));if(this._tree.setFocus(t),e.length>0){const e=this._tree.getFocus()[0];e&&this._tree.reveal(e)}}getActiveDescendant(){return this._tree.getHTMLElement().getAttribute("aria-activedescendant")}setSelectedElements(e){const t=e.map((e=>this._itemElements.find((t=>t.item===e)))).filter((e=>!!e));this._tree.setSelection(t)}getCheckedElements(){return this._itemElements.filter((e=>e.checked)).map((e=>e.item))}setCheckedElements(e){this._elementCheckedEventBufferer.bufferEvents((()=>{const t=new Set;for(const i of e)t.add(i);for(const e of this._itemElements)e.checked=t.has(e.item)}))}focus(e){if(this._itemElements.length)switch(e===zi.Fp.Second&&this._itemElements.length<2&&(e=zi.Fp.First),e){case zi.Fp.First:this._tree.scrollTop=0,this._tree.focusFirst(void 0,(e=>e.element instanceof js));break;case zi.Fp.Second:{this._tree.scrollTop=0;let e=!1;this._tree.focusFirst(void 0,(t=>t.element instanceof js&&(!!e||(e=!e,!1))));break}case zi.Fp.Last:this._tree.scrollTop=this._tree.scrollHeight,this._tree.focusLast(void 0,(e=>e.element instanceof js));break;case zi.Fp.Next:{const e=this._tree.getFocus();this._tree.focusNext(void 0,this._shouldLoop,void 0,(e=>e.element instanceof js&&(this._tree.reveal(e.element),!0)));const t=this._tree.getFocus();e.length&&e[0]===t[0]&&e[0]===this._itemElements[this._itemElements.length-1]&&this._onLeave.fire();break}case zi.Fp.Previous:{const e=this._tree.getFocus();this._tree.focusPrevious(void 0,this._shouldLoop,void 0,(e=>{if(!(e.element instanceof js))return!1;const t=this._tree.getParentElement(e.element);return null===t||t.children[0]!==e.element?this._tree.reveal(e.element):this._tree.reveal(t),!0}));const t=this._tree.getFocus();e.length&&e[0]===t[0]&&e[0]===this._itemElements[0]&&this._onLeave.fire();break}case zi.Fp.NextPage:this._tree.focusNextPage(void 0,(e=>e.element instanceof js&&(this._tree.reveal(e.element),!0)));break;case zi.Fp.PreviousPage:this._tree.focusPreviousPage(void 0,(e=>{if(!(e.element instanceof js))return!1;const t=this._tree.getParentElement(e.element);return null===t||t.children[0]!==e.element?this._tree.reveal(e.element):this._tree.reveal(t),!0}));break;case zi.Fp.NextSeparator:{let e=!1;const t=this._tree.getFocus()[0];this._tree.focusNext(void 0,!0,void 0,(t=>{if(e)return!0;if(t.element instanceof Ys)e=!0,this._separatorRenderer.isSeparatorVisible(t.element)?this._tree.reveal(t.element.children[0]):this._tree.reveal(t.element,0);else if(t.element instanceof js){if(t.element.separator)return this._itemRenderer.isItemWithSeparatorVisible(t.element)?this._tree.reveal(t.element):this._tree.reveal(t.element,0),!0;if(t.element===this._elementTree[0])return this._tree.reveal(t.element,0),!0}return!1}));t===this._tree.getFocus()[0]&&(this._tree.scrollTop=this._tree.scrollHeight,this._tree.focusLast(void 0,(e=>e.element instanceof js)));break}case zi.Fp.PreviousSeparator:{let e,t=!!this._tree.getFocus()[0]?.separator;this._tree.focusPrevious(void 0,!0,void 0,(i=>{if(i.element instanceof Ys)t?e||(this._separatorRenderer.isSeparatorVisible(i.element)?this._tree.reveal(i.element):this._tree.reveal(i.element,0),e=i.element.children[0]):t=!0;else if(i.element instanceof js&&!e)if(i.element.separator)this._itemRenderer.isItemWithSeparatorVisible(i.element)?this._tree.reveal(i.element):this._tree.reveal(i.element,0),e=i.element;else if(i.element===this._elementTree[0])return this._tree.reveal(i.element,0),!0;return!1})),e&&this._tree.setFocus([e]);break}}}clearFocus(){this._tree.setFocus([])}domFocus(){this._tree.domFocus()}layout(e){this._tree.getHTMLElement().style.maxHeight=e?44*Math.floor(e/44)+6+"px":"",this._tree.layout()}filter(e){if(this._lastQueryString=e,!(this._sortByLabel||this._matchOnLabel||this._matchOnDescription||this._matchOnDetail))return this._tree.layout(),!1;const t=e;if((e=e.trim())&&(this.matchOnLabel||this.matchOnDescription||this.matchOnDetail)){let i;this._itemElements.forEach((s=>{let n;n="fuzzy"===this.matchOnLabelMode?this.matchOnLabel?(0,pi.pz)(e,(0,pi._k)(s.saneLabel))??void 0:void 0:this.matchOnLabel?function(e,t){const{text:i,iconOffsets:s}=t;if(!s||0===s.length)return en(e,i);const n=(0,l.NB)(i," "),r=i.length-n.length,o=en(e,n);if(o)for(const a of o){const e=s[a.start+r]+r;a.start+=e,a.end+=e}return o}(t,(0,pi._k)(s.saneLabel))??void 0:void 0;const r=this.matchOnDescription?(0,pi.pz)(e,(0,pi._k)(s.saneDescription||""))??void 0:void 0,o=this.matchOnDetail?(0,pi.pz)(e,(0,pi._k)(s.saneDetail||""))??void 0:void 0;if(n||r||o?(s.labelHighlights=n,s.descriptionHighlights=r,s.detailHighlights=o,s.hidden=!1):(s.labelHighlights=void 0,s.descriptionHighlights=void 0,s.detailHighlights=void 0,s.hidden=!s.item||!s.item.alwaysShow),s.item?s.separator=void 0:s.separator&&(s.hidden=!0),!this.sortByLabel){const e=s.index&&this._inputElements[s.index-1]||void 0;"separator"!==e?.type||e.buttons||(i=e),i&&!s.hidden&&(s.separator=i,i=void 0)}}))}else this._itemElements.forEach((e=>{e.labelHighlights=void 0,e.descriptionHighlights=void 0,e.detailHighlights=void 0,e.hidden=!1;const t=e.index&&this._inputElements[e.index-1];e.item&&(e.separator=t&&"separator"===t.type&&!t.buttons?t:void 0)}));return this._setElementsToTree(this._sortByLabel&&e?this._itemElements:this._elementTree),this._tree.layout(),!0}toggleCheckbox(){this._elementCheckedEventBufferer.bufferEvents((()=>{const e=this._tree.getFocus().filter((e=>e instanceof js)),t=this._allVisibleChecked(e);for(const i of e)i.checkboxDisabled||(i.checked=!t)}))}style(e){this._tree.style(e)}toggleHover(){const e=this._tree.getFocus()[0];if(!e?.saneTooltip||!(e instanceof js))return;if(this._lastHover&&!this._lastHover.isDisposed)return void this._lastHover.dispose();this.showHover(e);const t=new c.Cm;t.add(this._tree.onDidChangeFocus((e=>{e.elements[0]instanceof js&&this.showHover(e.elements[0])}))),this._lastHover&&t.add(this._lastHover),this._elementDisposable.add(t)}_setElementsToTree(e){const t=new Array;for(const i of e)i instanceof Ys?t.push({element:i,collapsible:!1,collapsed:!1,children:i.children.map((e=>({element:e,collapsible:!1,collapsed:!1})))}):t.push({element:i,collapsible:!1,collapsed:!1});this._tree.setChildren(null,t)}_allVisibleChecked(e,t=!0){for(let i=0,s=e.length;i{this._allVisibleCheckedObservable.set(this._allVisibleChecked(this._itemElements,!1),e);const t=this._itemElements.filter((e=>e.checked)).length;this._checkedCountObservable.set(t,e),this._checkedElementsObservable.set(this.getCheckedElements(),e)}))}showHover(e){this._lastHover&&!this._lastHover.isDisposed&&(this.hoverDelegate.onDidHideHover?.(),this._lastHover?.dispose()),e.element&&e.saneTooltip&&(this._lastHover=this.hoverDelegate.showHover({content:e.saneTooltip,target:e.element,linkHandler:e=>{this.linkOpenerDelegate(e)},appearance:{showPointer:!0},container:this._container,position:{hoverPosition:1}},!1))}};function en(e,t){const i=t.toLowerCase().indexOf(e.toLowerCase());return-1!==i?[{start:i,end:i+e.length}]:null}Ws([Xi.B],Js.prototype,"onDidChangeFocus",null),Ws([Xi.B],Js.prototype,"onDidChangeSelection",null),Js=Ws([Vs(4,ae._Y),Vs(5,Ve.j)],Js);var tn=i(28290);const sn={weight:200,when:ie.M$.and(ie.M$.equals(hs,"quickPick"),ls),metadata:{description:(0,b.kg)("quickPick","Used while in the context of the quick pick. If you change one keybinding for this command, you should change all of the other keybindings (modifier variants) of this command as well.")}};function nn(e,t={}){Wt.f.registerCommandAndKeybindingRule({...sn,...e,secondary:on(e.primary,e.secondary??[],t)})}const rn=We.zx?256:2048;function on(e,t,i={}){return i.withAltMod&&t.push(512+e),i.withCtrlMod&&(t.push(rn+e),i.withAltMod&&t.push(512+rn+e)),i.withCmdMod&&We.zx&&(t.push(2048+e),i.withCtrlMod&&t.push(2304+e),i.withAltMod&&(t.push(2560+e),i.withCtrlMod&&t.push(2816+e))),t}function an(e,t){return i=>{const s=i.get(zi.GK).currentQuickInput;if(s)return t&&s.quickNavigate?s.focus(t):s.focus(e)}}nn({id:"quickInput.pageNext",primary:12,handler:an(zi.Fp.NextPage)},{withAltMod:!0,withCtrlMod:!0,withCmdMod:!0}),nn({id:"quickInput.pagePrevious",primary:11,handler:an(zi.Fp.PreviousPage)},{withAltMod:!0,withCtrlMod:!0,withCmdMod:!0}),nn({id:"quickInput.first",primary:rn+14,handler:an(zi.Fp.First)},{withAltMod:!0,withCmdMod:!0}),nn({id:"quickInput.last",primary:rn+13,handler:an(zi.Fp.Last)},{withAltMod:!0,withCmdMod:!0}),nn({id:"quickInput.next",primary:18,handler:an(zi.Fp.Next)},{withCtrlMod:!0}),nn({id:"quickInput.previous",primary:16,handler:an(zi.Fp.Previous)},{withCtrlMod:!0});const cn=(0,b.kg)("quickInput.nextSeparatorWithQuickAccessFallback","If we're in quick access mode, this will navigate to the next item. If we are not in quick access mode, this will navigate to the next separator."),ln=(0,b.kg)("quickInput.previousSeparatorWithQuickAccessFallback","If we're in quick access mode, this will navigate to the previous item. If we are not in quick access mode, this will navigate to the previous separator.");We.zx?(nn({id:"quickInput.nextSeparatorWithQuickAccessFallback",primary:2066,handler:an(zi.Fp.NextSeparator,zi.Fp.Next),metadata:{description:cn}}),nn({id:"quickInput.nextSeparator",primary:2578,secondary:[2322],handler:an(zi.Fp.NextSeparator)},{withCtrlMod:!0}),nn({id:"quickInput.previousSeparatorWithQuickAccessFallback",primary:2064,handler:an(zi.Fp.PreviousSeparator,zi.Fp.Previous),metadata:{description:ln}}),nn({id:"quickInput.previousSeparator",primary:2576,secondary:[2320],handler:an(zi.Fp.PreviousSeparator)},{withCtrlMod:!0})):(nn({id:"quickInput.nextSeparatorWithQuickAccessFallback",primary:530,handler:an(zi.Fp.NextSeparator,zi.Fp.Next),metadata:{description:cn}}),nn({id:"quickInput.nextSeparator",primary:2578,handler:an(zi.Fp.NextSeparator)}),nn({id:"quickInput.previousSeparatorWithQuickAccessFallback",primary:528,handler:an(zi.Fp.PreviousSeparator,zi.Fp.Previous),metadata:{description:ln}}),nn({id:"quickInput.previousSeparator",primary:2576,handler:an(zi.Fp.PreviousSeparator)})),nn({id:"quickInput.acceptInBackground",when:ie.M$.and(sn.when,ie.M$.or(tn.J7.negate(),ps)),primary:17,weight:250,handler:e=>{const t=e.get(zi.GK).currentQuickInput;t?.accept(!0)}},{withAltMod:!0,withCtrlMod:!0,withCmdMod:!0});var hn,dn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},un=function(e,t){return function(i,s){t(i,s,e)}};const gn=U.$;let pn=class extends c.jG{static{hn=this}static{this.MAX_WIDTH=600}get currentQuickInput(){return this.controller??void 0}get container(){return this._container}constructor(e,t,i,s){super(),this.options=e,this.layoutService=t,this.instantiationService=i,this.contextKeyService=s,this.enabled=!0,this.onDidAcceptEmitter=this._register(new Q.vl),this.onDidCustomEmitter=this._register(new Q.vl),this.onDidTriggerButtonEmitter=this._register(new Q.vl),this.keyMods={ctrlCmd:!1,alt:!1},this.controller=null,this.onShowEmitter=this._register(new Q.vl),this.onShow=this.onShowEmitter.event,this.onHideEmitter=this._register(new Q.vl),this.onHide=this.onHideEmitter.event,this.inQuickInputContext=cs.bindTo(this.contextKeyService),this.quickInputTypeContext=ds.bindTo(this.contextKeyService),this.endOfQuickInputBoxContext=gs.bindTo(this.contextKeyService),this.idPrefix=e.idPrefix,this._container=e.container,this.styles=e.styles,this._register(Q.Jh.runAndSubscribe(U.Iv,(({window:e,disposables:t})=>this.registerKeyModsListeners(e,t)),{window:a.G,disposables:this._store})),this._register(U.q3((e=>{this.ui&&U.zk(this.ui.container)===e&&(this.reparentUI(this.layoutService.mainContainer),this.layout(this.layoutService.mainContainerDimension,this.layoutService.mainContainerOffset.quickPickTop))})))}registerKeyModsListeners(e,t){const i=e=>{this.keyMods.ctrlCmd=e.ctrlKey||e.metaKey,this.keyMods.alt=e.altKey};for(const s of[U.Bx.KEY_DOWN,U.Bx.KEY_UP,U.Bx.MOUSE_DOWN])t.add(U.ko(e,s,i,!0))}getUI(e){if(this.ui)return e&&U.zk(this._container)!==U.zk(this.layoutService.activeContainer)&&(this.reparentUI(this.layoutService.activeContainer),this.layout(this.layoutService.activeContainerDimension,this.layoutService.activeContainerOffset.quickPickTop)),this.ui;const t=U.BC(this._container,gn(".quick-input-widget.show-file-icons"));t.tabIndex=-1,t.style.display="none";const i=U.li(t),s=U.BC(t,gn(".quick-input-titlebar")),n=this._register(new ci.E(s,{hoverDelegate:this.options.hoverDelegate}));n.domNode.classList.add("quick-input-left-action-bar");const r=U.BC(s,gn(".quick-input-title")),o=this._register(new ci.E(s,{hoverDelegate:this.options.hoverDelegate}));o.domNode.classList.add("quick-input-right-action-bar");const a=U.BC(t,gn(".quick-input-header")),c=U.BC(a,gn("input.quick-input-check-all"));c.type="checkbox",c.setAttribute("aria-label",(0,b.kg)("quickInput.checkAll","Toggle all checkboxes")),this._register(U.b2(c,U.Bx.CHANGE,(e=>{const t=c.checked;x.setAllVisibleChecked(t)}))),this._register(U.ko(c,U.Bx.CLICK,(e=>{(e.x||e.y)&&u.setFocus()})));const l=U.BC(a,gn(".quick-input-description")),h=U.BC(a,gn(".quick-input-and-message")),d=U.BC(h,gn(".quick-input-filter")),u=this._register(new As(d,this.styles.inputBox,this.styles.toggle));u.setAttribute("aria-describedby",`${this.idPrefix}message`);const g=U.BC(d,gn(".quick-input-visible-count"));g.setAttribute("aria-live","polite"),g.setAttribute("aria-atomic","true");const p=new bs.x(g,{countFormat:(0,b.kg)({key:"quickInput.visibleCount",comment:["This tells the user how many items are shown in a list of items to select from. The items can be anything. Currently not visible, but read by screen readers."]},"{0} Results")},this.styles.countBadge),m=U.BC(d,gn(".quick-input-count"));m.setAttribute("aria-live","polite");const f=new bs.x(m,{countFormat:(0,b.kg)({key:"quickInput.countSelected",comment:["This tells the user how many items are selected in a list of items to select from. The items can be anything."]},"{0} Selected")},this.styles.countBadge),_=this._register(new ci.E(a,{hoverDelegate:this.options.hoverDelegate}));_.domNode.classList.add("quick-input-inline-action-bar");const v=U.BC(a,gn(".quick-input-action")),C=this._register(new Es.$(v,this.styles.button));C.label=(0,b.kg)("ok","OK"),this._register(C.onDidClick((e=>{this.onDidAcceptEmitter.fire()})));const E=U.BC(a,gn(".quick-input-action")),S=this._register(new Es.$(E,{...this.styles.button,supportIcons:!0}));S.label=(0,b.kg)("custom","Custom"),this._register(S.onDidClick((e=>{this.onDidCustomEmitter.fire()})));const y=U.BC(h,gn(`#${this.idPrefix}message.quick-input-message`)),w=this._register(new Ts(t,this.styles.progressBar));w.getContainer().classList.add("quick-input-progress");const R=U.BC(t,gn(".quick-input-html-widget"));R.tabIndex=-1;const L=U.BC(t,gn(".quick-input-description")),T=this.idPrefix+"list",x=this._register(this.instantiationService.createInstance(Js,t,this.options.hoverDelegate,this.options.linkOpenerDelegate,T));u.setAttribute("aria-controls",T),this._register(x.onDidChangeFocus((()=>{u.setAttribute("aria-activedescendant",x.getActiveDescendant()??"")}))),this._register(x.onChangedAllVisibleChecked((e=>{c.checked=e}))),this._register(x.onChangedVisibleCount((e=>{p.setCount(e)}))),this._register(x.onChangedCheckedCount((e=>{f.setCount(e)}))),this._register(x.onLeave((()=>{setTimeout((()=>{this.controller&&(u.setFocus(),this.controller instanceof _s&&this.controller.canSelectMany&&x.clearFocus())}),0)})));const k=U.w5(t);return this._register(k),this._register(U.ko(t,U.Bx.FOCUS,(e=>{const t=this.getUI();if(U.QX(e.relatedTarget,t.inputContainer)){const e=t.inputBox.isSelectionAtEnd();this.endOfQuickInputBoxContext.get()!==e&&this.endOfQuickInputBoxContext.set(e)}U.QX(e.relatedTarget,t.container)||(this.inQuickInputContext.set(!0),this.previousFocusElement=U.sb(e.relatedTarget)?e.relatedTarget:void 0)}),!0)),this._register(k.onDidBlur((()=>{this.getUI().ignoreFocusOut||this.options.ignoreFocusOut()||this.hide(zi.kF.Blur),this.inQuickInputContext.set(!1),this.endOfQuickInputBoxContext.set(!1),this.previousFocusElement=void 0}))),this._register(u.onKeyDown((e=>{const t=this.getUI().inputBox.isSelectionAtEnd();this.endOfQuickInputBoxContext.get()!==t&&this.endOfQuickInputBoxContext.set(t)}))),this._register(U.ko(t,U.Bx.FOCUS,(e=>{u.setFocus()}))),this._register(U.b2(t,U.Bx.KEY_DOWN,(e=>{if(!U.QX(e.target,R))switch(e.keyCode){case 3:U.fs.stop(e,!0),this.enabled&&this.onDidAcceptEmitter.fire();break;case 9:U.fs.stop(e,!0),this.hide(zi.kF.Gesture);break;case 2:if(!e.altKey&&!e.ctrlKey&&!e.metaKey){const i=[".quick-input-list .monaco-action-bar .always-visible",".quick-input-list-entry:hover .monaco-action-bar",".monaco-list-row.focused .monaco-action-bar"];if(t.classList.contains("show-checkboxes")?i.push("input"):i.push("input[type=text]"),this.getUI().list.displayed&&i.push(".monaco-list"),this.getUI().message&&i.push(".quick-input-message a"),this.getUI().widget){if(U.QX(e.target,this.getUI().widget))break;i.push(".quick-input-html-widget")}const s=t.querySelectorAll(i.join(", "));e.shiftKey&&e.target===s[0]?(U.fs.stop(e,!0),x.clearFocus()):!e.shiftKey&&U.QX(e.target,s[s.length-1])&&(U.fs.stop(e,!0),s[0].focus())}break;case 10:e.ctrlKey&&(U.fs.stop(e,!0),this.getUI().list.toggleHover())}}))),this.ui={container:t,styleSheet:i,leftActionBar:n,titleBar:s,title:r,description1:L,description2:l,widget:R,rightActionBar:o,inlineActionBar:_,checkAll:c,inputContainer:h,filterContainer:d,inputBox:u,visibleCountContainer:g,visibleCount:p,countContainer:m,count:f,okContainer:v,ok:C,message:y,customButtonContainer:E,customButton:S,list:x,progressBar:w,onDidAccept:this.onDidAcceptEmitter.event,onDidCustom:this.onDidCustomEmitter.event,onDidTriggerButton:this.onDidTriggerButtonEmitter.event,ignoreFocusOut:!1,keyMods:this.keyMods,show:e=>this.show(e),hide:()=>this.hide(),setVisibilities:e=>this.setVisibilities(e),setEnabled:e=>this.setEnabled(e),setContextKey:e=>this.options.setContextKey(e),linkOpenerDelegate:e=>this.options.linkOpenerDelegate(e)},this.updateStyles(),this.ui}reparentUI(e){this.ui&&(this._container=e,U.BC(this._container,this.ui.container))}pick(e,t={},i=at.XO.None){return new Promise(((s,n)=>{let r=e=>{r=s,t.onKeyMods?.(o.keyMods),s(e)};if(i.isCancellationRequested)return void r(void 0);const o=this.createQuickPick({useSeparators:!0});let a;const l=[o,o.onDidAccept((()=>{if(o.canSelectMany)r(o.selectedItems.slice()),o.hide();else{const e=o.activeItems[0];e&&(r(e),o.hide())}})),o.onDidChangeActive((e=>{const i=e[0];i&&t.onDidFocus&&t.onDidFocus(i)})),o.onDidChangeSelection((e=>{if(!o.canSelectMany){const t=e[0];t&&(r(t),o.hide())}})),o.onDidTriggerItemButton((e=>t.onDidTriggerItemButton&&t.onDidTriggerItemButton({...e,removeItem:()=>{const t=o.items.indexOf(e.item);if(-1!==t){const e=o.items.slice(),i=e.splice(t,1),s=o.activeItems.filter((e=>e!==i[0])),n=o.keepScrollPosition;o.keepScrollPosition=!0,o.items=e,s&&(o.activeItems=s),o.keepScrollPosition=n}}}))),o.onDidTriggerSeparatorButton((e=>t.onDidTriggerSeparatorButton?.(e))),o.onDidChangeValue((e=>{!a||e||1===o.activeItems.length&&o.activeItems[0]===a||(o.activeItems=[a])})),i.onCancellationRequested((()=>{o.hide()})),o.onDidHide((()=>{(0,c.AS)(l),r(void 0)}))];o.title=t.title,t.value&&(o.value=t.value),o.canSelectMany=!!t.canPickMany,o.placeholder=t.placeHolder,o.ignoreFocusOut=!!t.ignoreFocusLost,o.matchOnDescription=!!t.matchOnDescription,o.matchOnDetail=!!t.matchOnDetail,o.matchOnLabel=void 0===t.matchOnLabel||t.matchOnLabel,o.quickNavigate=t.quickNavigate,o.hideInput=!!t.hideInput,o.contextKey=t.contextKey,o.busy=!0,Promise.all([e,t.activeItem]).then((([e,t])=>{a=t,o.busy=!1,o.items=e,o.canSelectMany&&(o.selectedItems=e.filter((e=>"separator"!==e.type&&e.picked))),a&&(o.activeItems=[a])})),o.show(),Promise.resolve(e).then(void 0,(e=>{n(e),o.hide()}))}))}createQuickPick(e={useSeparators:!1}){const t=this.getUI(!0);return new _s(t)}createInputBox(){const e=this.getUI(!0);return new vs(e)}show(e){const t=this.getUI(!0);this.onShowEmitter.fire();const i=this.controller;this.controller=e,i?.didHide(),this.setEnabled(!0),t.leftActionBar.clear(),t.title.textContent="",t.description1.textContent="",t.description2.textContent="",U.Ln(t.widget),t.rightActionBar.clear(),t.inlineActionBar.clear(),t.checkAll.checked=!1,t.inputBox.placeholder="",t.inputBox.password=!1,t.inputBox.showDecoration(ge.A.Ignore),t.visibleCount.setCount(0),t.count.setCount(0),U.Ln(t.message),t.progressBar.stop(),t.list.setElements([]),t.list.matchOnDescription=!1,t.list.matchOnDetail=!1,t.list.matchOnLabel=!0,t.list.sortByLabel=!0,t.ignoreFocusOut=!1,t.inputBox.toggles=void 0;const s=this.options.backKeybindingLabel();ms.tooltip=s?(0,b.kg)("quickInput.backWithKeybinding","Back ({0})",s):(0,b.kg)("quickInput.back","Back"),t.container.style.display="",this.updateLayout(),t.inputBox.setFocus(),this.quickInputTypeContext.set(e.type)}isVisible(){return!!this.ui&&"none"!==this.ui.container.style.display}setVisibilities(e){const t=this.getUI();t.title.style.display=e.title?"":"none",t.description1.style.display=e.description&&(e.inputBox||e.checkAll)?"":"none",t.description2.style.display=!e.description||e.inputBox||e.checkAll?"none":"",t.checkAll.style.display=e.checkAll?"":"none",t.inputContainer.style.display=e.inputBox?"":"none",t.filterContainer.style.display=e.inputBox?"":"none",t.visibleCountContainer.style.display=e.visibleCount?"":"none",t.countContainer.style.display=e.count?"":"none",t.okContainer.style.display=e.ok?"":"none",t.customButtonContainer.style.display=e.customButton?"":"none",t.message.style.display=e.message?"":"none",t.progressBar.getContainer().style.display=e.progressBar?"":"none",t.list.displayed=!!e.list,t.container.classList.toggle("show-checkboxes",!!e.checkBox),t.container.classList.toggle("hidden-input",!e.inputBox&&!e.description),this.updateLayout()}setEnabled(e){if(e!==this.enabled){this.enabled=e;for(const t of this.getUI().leftActionBar.viewItems)t.action.enabled=e;for(const t of this.getUI().rightActionBar.viewItems)t.action.enabled=e;this.getUI().checkAll.disabled=!e,this.getUI().inputBox.enabled=e,this.getUI().ok.enabled=e,this.getUI().list.enabled=e}}hide(e){const t=this.controller;if(!t)return;t.willHide(e);const i=this.ui?.container,s=i&&!U.nR(i);if(this.controller=null,this.onHideEmitter.fire(),i&&(i.style.display="none"),!s){let e=this.previousFocusElement;for(;e&&!e.offsetParent;)e=e.parentElement??void 0;e?.offsetParent?(e.focus(),this.previousFocusElement=void 0):this.options.returnFocus()}t.didHide(e)}layout(e,t){this.dimension=e,this.titleBarOffset=t,this.updateLayout()}updateLayout(){if(this.ui&&this.isVisible()){this.ui.container.style.top=`${this.titleBarOffset}px`;const e=this.ui.container.style,t=Math.min(.62*this.dimension.width,hn.MAX_WIDTH);e.width=t+"px",e.marginLeft="-"+t/2+"px",this.ui.inputBox.layout(),this.ui.list.layout(this.dimension&&.4*this.dimension.height)}}applyStyles(e){this.styles=e,this.updateStyles()}updateStyles(){if(this.ui){const{quickInputTitleBackground:e,quickInputBackground:t,quickInputForeground:i,widgetBorder:s,widgetShadow:n}=this.styles.widget;this.ui.titleBar.style.backgroundColor=e??"",this.ui.container.style.backgroundColor=t??"",this.ui.container.style.color=i??"",this.ui.container.style.border=s?`1px solid ${s}`:"",this.ui.container.style.boxShadow=n?`0 0 8px 2px ${n}`:"",this.ui.list.style(this.styles.list);const r=[];this.styles.pickerGroup.pickerGroupBorder&&r.push(`.quick-input-list .quick-input-list-entry { border-top-color: ${this.styles.pickerGroup.pickerGroupBorder}; }`),this.styles.pickerGroup.pickerGroupForeground&&r.push(`.quick-input-list .quick-input-list-separator { color: ${this.styles.pickerGroup.pickerGroupForeground}; }`),this.styles.pickerGroup.pickerGroupForeground&&r.push(".quick-input-list .quick-input-list-separator-as-item { color: var(--vscode-descriptionForeground); }"),(this.styles.keybindingLabel.keybindingLabelBackground||this.styles.keybindingLabel.keybindingLabelBorder||this.styles.keybindingLabel.keybindingLabelBottomBorder||this.styles.keybindingLabel.keybindingLabelShadow||this.styles.keybindingLabel.keybindingLabelForeground)&&(r.push(".quick-input-list .monaco-keybinding > .monaco-keybinding-key {"),this.styles.keybindingLabel.keybindingLabelBackground&&r.push(`background-color: ${this.styles.keybindingLabel.keybindingLabelBackground};`),this.styles.keybindingLabel.keybindingLabelBorder&&r.push(`border-color: ${this.styles.keybindingLabel.keybindingLabelBorder};`),this.styles.keybindingLabel.keybindingLabelBottomBorder&&r.push(`border-bottom-color: ${this.styles.keybindingLabel.keybindingLabelBottomBorder};`),this.styles.keybindingLabel.keybindingLabelShadow&&r.push(`box-shadow: inset 0 -1px 0 ${this.styles.keybindingLabel.keybindingLabelShadow};`),this.styles.keybindingLabel.keybindingLabelForeground&&r.push(`color: ${this.styles.keybindingLabel.keybindingLabelForeground};`),r.push("}"));const o=r.join("\n");o!==this.ui.styleSheet.textContent&&(this.ui.styleSheet.textContent=o)}}};pn=hn=dn([un(1,ce),un(2,ae._Y),un(3,ie.fN)],pn);var mn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},fn=function(e,t){return function(i,s){t(i,s,e)}};let _n=class extends Z.lR{get controller(){return this._controller||(this._controller=this._register(this.createController())),this._controller}get hasController(){return!!this._controller}get currentQuickInput(){return this.controller.currentQuickInput}get quickAccess(){return this._quickAccess||(this._quickAccess=this._register(this.instantiationService.createInstance(Ki))),this._quickAccess}constructor(e,t,i,s,n){super(i),this.instantiationService=e,this.contextKeyService=t,this.layoutService=s,this.configurationService=n,this._onShow=this._register(new Q.vl),this._onHide=this._register(new Q.vl),this.contexts=new Map}createController(e=this.layoutService,t){const i={idPrefix:"quickInput_",container:e.activeContainer,ignoreFocusOut:()=>!1,backKeybindingLabel:()=>{},setContextKey:e=>this.setContextKey(e),linkOpenerDelegate:e=>{this.instantiationService.invokeFunction((t=>{t.get(Ue.C).open(e,{allowCommands:!0,fromUserGesture:!0})}))},returnFocus:()=>e.focus(),styles:this.computeStyles(),hoverDelegate:this._register(this.instantiationService.createInstance(Cs))},s=this._register(this.instantiationService.createInstance(pn,{...i,...t}));return s.layout(e.activeContainerDimension,e.activeContainerOffset.quickPickTop),this._register(e.onDidLayoutActiveContainer((t=>{(0,U.zk)(e.activeContainer)===(0,U.zk)(s.container)&&s.layout(t,e.activeContainerOffset.quickPickTop)}))),this._register(e.onDidChangeActiveContainer((()=>{s.isVisible()||s.layout(e.activeContainerDimension,e.activeContainerOffset.quickPickTop)}))),this._register(s.onShow((()=>{this.resetContextKeys(),this._onShow.fire()}))),this._register(s.onHide((()=>{this.resetContextKeys(),this._onHide.fire()}))),s}setContextKey(e){let t;e&&(t=this.contexts.get(e),t||(t=new ie.N1(e,!1).bindTo(this.contextKeyService),this.contexts.set(e,t))),t&&t.get()||(this.resetContextKeys(),t?.set(!0))}resetContextKeys(){this.contexts.forEach((e=>{e.get()&&e.reset()}))}pick(e,t,i=at.XO.None){return this.controller.pick(e,t,i)}createQuickPick(e={useSeparators:!1}){return this.controller.createQuickPick(e)}createInputBox(){return this.controller.createInputBox()}updateStyles(){this.hasController&&this.controller.applyStyles(this.computeStyles())}computeStyles(){return{widget:{quickInputBackground:(0,Ne.GuP)(Ne.ELA),quickInputForeground:(0,Ne.GuP)(Ne.HJZ),quickInputTitleBackground:(0,Ne.GuP)(Ne.er1),widgetBorder:(0,Ne.GuP)(Ne.DSL),widgetShadow:(0,Ne.GuP)(Ne.f9l)},inputBox:wi.ho,toggle:wi.mk,countBadge:wi.m$,button:wi.cv,progressBar:wi.oJ,keybindingLabel:wi.ir,list:(0,wi.t8)({listBackground:Ne.ELA,listFocusBackground:Ne.AlL,listFocusForeground:Ne.nH,listInactiveFocusForeground:Ne.nH,listInactiveSelectionIconForeground:Ne.c7i,listInactiveFocusBackground:Ne.AlL,listFocusOutline:Ne.buw,listInactiveFocusOutline:Ne.buw}),pickerGroup:{pickerGroupBorder:(0,Ne.GuP)(Ne.iwL),pickerGroupForeground:(0,Ne.GuP)(Ne.NBf)}}}};_n=mn([fn(0,ae._Y),fn(1,ie.fN),fn(2,Z.Gy),fn(3,ce),fn(4,Me.pG)],_n);var vn=i(6921),Cn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},En=function(e,t){return function(i,s){t(i,s,e)}};let bn=class extends _n{constructor(e,t,i,s,n,r){super(t,i,s,new ue(e.getContainerDomNode(),n),r),this.host=void 0;const o=yn.get(e);if(o){const t=o.widget;this.host={_serviceBrand:void 0,get mainContainer(){return t.getDomNode()},getContainer:()=>t.getDomNode(),whenContainerStylesLoaded(){},get containers(){return[t.getDomNode()]},get activeContainer(){return t.getDomNode()},get mainContainerDimension(){return e.getLayoutInfo()},get activeContainerDimension(){return e.getLayoutInfo()},get onDidLayoutMainContainer(){return e.onDidLayoutChange},get onDidLayoutActiveContainer(){return e.onDidLayoutChange},get onDidLayoutContainer(){return Q.Jh.map(e.onDidLayoutChange,(e=>({container:t.getDomNode(),dimension:e})))},get onDidChangeActiveContainer(){return Q.Jh.None},get onDidAddContainer(){return Q.Jh.None},get mainContainerOffset(){return{top:0,quickPickTop:0}},get activeContainerOffset(){return{top:0,quickPickTop:0}},focus:()=>e.focus()}}else this.host=void 0}createController(){return super.createController(this.host)}};bn=Cn([En(1,ae._Y),En(2,ie.fN),En(3,Z.Gy),En(4,g.T),En(5,Me.pG)],bn);let Sn=class{get activeService(){const e=this.codeEditorService.getFocusedCodeEditor();if(!e)throw new Error("Quick input service needs a focused editor to work.");let t=this.mapEditorToService.get(e);if(!t){const i=t=this.instantiationService.createInstance(bn,e);this.mapEditorToService.set(e,t),(0,vn.P)(e.onDidDispose)((()=>{i.dispose(),this.mapEditorToService.delete(e)}))}return t}get currentQuickInput(){return this.activeService.currentQuickInput}get quickAccess(){return this.activeService.quickAccess}constructor(e,t){this.instantiationService=e,this.codeEditorService=t,this.mapEditorToService=new Map}pick(e,t,i=at.XO.None){return this.activeService.pick(e,t,i)}createQuickPick(e={useSeparators:!1}){return this.activeService.createQuickPick(e)}createInputBox(){return this.activeService.createInputBox()}};Sn=Cn([En(0,ae._Y),En(1,g.T)],Sn);class yn{static{this.ID="editor.controller.quickInput"}static get(e){return e.getContribution(yn.ID)}constructor(e){this.editor=e,this.widget=new wn(this.editor)}dispose(){this.widget.dispose()}}class wn{static{this.ID="editor.contrib.quickInputWidget"}constructor(e){this.codeEditor=e,this.domNode=document.createElement("div"),this.codeEditor.addOverlayWidget(this)}getId(){return wn.ID}getDomNode(){return this.domNode}getPosition(){return{preference:2}}dispose(){this.codeEditor.removeOverlayWidget(this)}}(0,u.HW)(yn.ID,yn,4);var Rn=i(10424),Ln=i(24520),Tn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xn=function(e,t){return function(i,s){t(i,s,e)}};let kn=class extends c.jG{constructor(e,t,i){super(),this._contextKeyService=e,this._layoutService=t,this._configurationService=i,this._accessibilitySupport=0,this._onDidChangeScreenReaderOptimized=new Q.vl,this._onDidChangeReducedMotion=new Q.vl,this._onDidChangeLinkUnderline=new Q.vl,this._accessibilityModeEnabledContext=Ve.f.bindTo(this._contextKeyService);const s=()=>this._accessibilityModeEnabledContext.set(this.isScreenReaderOptimized());this._register(this._configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration("editor.accessibilitySupport")&&(s(),this._onDidChangeScreenReaderOptimized.fire()),e.affectsConfiguration("workbench.reduceMotion")&&(this._configMotionReduced=this._configurationService.getValue("workbench.reduceMotion"),this._onDidChangeReducedMotion.fire())}))),s(),this._register(this.onDidChangeScreenReaderOptimized((()=>s())));const n=a.G.matchMedia("(prefers-reduced-motion: reduce)");this._systemMotionReduced=n.matches,this._configMotionReduced=this._configurationService.getValue("workbench.reduceMotion"),this._linkUnderlinesEnabled=this._configurationService.getValue("accessibility.underlineLinks"),this.initReducedMotionListeners(n),this.initLinkUnderlineListeners()}initReducedMotionListeners(e){this._register((0,U.ko)(e,"change",(()=>{this._systemMotionReduced=e.matches,"auto"===this._configMotionReduced&&this._onDidChangeReducedMotion.fire()})));const t=()=>{const e=this.isMotionReduced();this._layoutService.mainContainer.classList.toggle("reduce-motion",e),this._layoutService.mainContainer.classList.toggle("enable-motion",!e)};t(),this._register(this.onDidChangeReducedMotion((()=>t())))}initLinkUnderlineListeners(){this._register(this._configurationService.onDidChangeConfiguration((e=>{if(e.affectsConfiguration("accessibility.underlineLinks")){const e=this._configurationService.getValue("accessibility.underlineLinks");this._linkUnderlinesEnabled=e,this._onDidChangeLinkUnderline.fire()}})));const e=()=>{const e=this._linkUnderlinesEnabled;this._layoutService.mainContainer.classList.toggle("underline-links",e)};e(),this._register(this.onDidChangeLinkUnderlines((()=>e())))}onDidChangeLinkUnderlines(e){return this._onDidChangeLinkUnderline.event(e)}get onDidChangeScreenReaderOptimized(){return this._onDidChangeScreenReaderOptimized.event}isScreenReaderOptimized(){const e=this._configurationService.getValue("editor.accessibilitySupport");return"on"===e||"auto"===e&&2===this._accessibilitySupport}get onDidChangeReducedMotion(){return this._onDidChangeReducedMotion.event}isMotionReduced(){const e=this._configMotionReduced;return"on"===e||"auto"===e&&this._systemMotionReduced}getAccessibilitySupport(){return this._accessibilitySupport}};kn=Tn([xn(0,ie.fN),xn(1,ce),xn(2,Me.pG)],kn);var An,Nn=i(60858),In=i(85600),On=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Dn=function(e,t){return function(i,s){t(i,s,e)}};const Mn="application/vnd.code.resources";let Pn=class extends c.jG{static{An=this}constructor(e,t){super(),this.layoutService=e,this.logService=t,this.mapTextToType=new Map,this.findText="",this.resources=[],this.resourcesStateHash=void 0,(oi.nr||oi.c8)&&this.installWebKitWriteTextWorkaround(),this._register(Q.Jh.runAndSubscribe(U.Iv,(({window:e,disposables:t})=>{t.add((0,U.ko)(e.document,"copy",(()=>this.clearResourcesState())))}),{window:a.G,disposables:this._store}))}installWebKitWriteTextWorkaround(){const e=()=>{const e=new m.Zv;this.webKitPendingClipboardWritePromise&&!this.webKitPendingClipboardWritePromise.isSettled&&this.webKitPendingClipboardWritePromise.cancel(),this.webKitPendingClipboardWritePromise=e,(0,U.fz)().navigator.clipboard.write([new ClipboardItem({"text/plain":e.p})]).catch((async t=>{t instanceof Error&&"NotAllowedError"===t.name&&e.isRejected||this.logService.error(t)}))};this._register(Q.Jh.runAndSubscribe(this.layoutService.onDidAddContainer,(({container:t,disposables:i})=>{i.add((0,U.ko)(t,"click",e)),i.add((0,U.ko)(t,"keydown",e))}),{container:this.layoutService.mainContainer,disposables:this._store}))}async writeText(e,t){if(this.clearResourcesState(),t)this.mapTextToType.set(t,e);else{if(this.webKitPendingClipboardWritePromise)return this.webKitPendingClipboardWritePromise.complete(e);try{return await(0,U.fz)().navigator.clipboard.writeText(e)}catch(i){console.error(i)}this.fallbackWriteText(e)}}fallbackWriteText(e){const t=(0,U.a)(),i=t.activeElement,s=t.body.appendChild((0,U.$)("textarea",{"aria-hidden":!0}));s.style.height="1px",s.style.width="1px",s.style.position="absolute",s.value=e,s.focus(),s.select(),t.execCommand("copy"),(0,U.sb)(i)&&i.focus(),s.remove()}async readText(e){if(e)return this.mapTextToType.get(e)||"";try{return await(0,U.fz)().navigator.clipboard.readText()}catch(t){console.error(t)}return""}async readFindText(){return this.findText}async writeFindText(e){this.findText=e}static{this.MAX_RESOURCE_STATE_SOURCE_LENGTH=1e3}async readResources(){try{const e=await(0,U.fz)().navigator.clipboard.read();for(const t of e)if(t.types.includes(`web ${Mn}`)){const e=await t.getType(`web ${Mn}`);return JSON.parse(await e.text()).map((e=>h.r.from(e)))}}catch(t){}const e=await this.computeResourcesStateHash();return this.resourcesStateHash!==e&&this.clearResourcesState(),this.resources}async computeResourcesStateHash(){if(0===this.resources.length)return;const e=await this.readText();return(0,In.tW)(e.substring(0,An.MAX_RESOURCE_STATE_SOURCE_LENGTH))}clearInternalState(){this.clearResourcesState()}clearResourcesState(){this.resources=[],this.resourcesStateHash=void 0}};Pn=An=On([Dn(0,ce),Dn(1,I.rr)],Pn);var Fn=i(54770),Un=i(42522),Hn=i(4853),Bn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Wn=function(e,t){return function(i,s){t(i,s,e)}};const Vn="data-keybinding-context";class zn{constructor(e,t){this._id=e,this._parent=t,this._value=Object.create(null),this._value._contextId=e}get value(){return{...this._value}}setValue(e,t){return this._value[e]!==t&&(this._value[e]=t,!0)}removeValue(e){return e in this._value&&(delete this._value[e],!0)}getValue(e){const t=this._value[e];return"undefined"===typeof t&&this._parent?this._parent.getValue(e):t}}class Gn extends zn{static{this.INSTANCE=new Gn}constructor(){super(-1,null)}setValue(e,t){return!1}removeValue(e){return!1}getValue(e){}}class jn extends zn{static{this._keyPrefix="config."}constructor(e,t,i){super(e,null),this._configurationService=t,this._values=Hn.cB.forConfigKeys(),this._listener=this._configurationService.onDidChangeConfiguration((e=>{if(7===e.source){const e=Array.from(this._values,(([e])=>e));this._values.clear(),i.fire(new qn(e))}else{const t=[];for(const i of e.affectedKeys){const e=`config.${i}`,s=this._values.findSuperstr(e);void 0!==s&&(t.push(...Un.f.map(s,(([e])=>e))),this._values.deleteSuperstr(e)),this._values.has(e)&&(t.push(e),this._values.delete(e))}i.fire(new qn(t))}}))}dispose(){this._listener.dispose()}getValue(e){if(0!==e.indexOf(jn._keyPrefix))return super.getValue(e);if(this._values.has(e))return this._values.get(e);const t=e.substr(jn._keyPrefix.length),i=this._configurationService.getValue(t);let s;switch(typeof i){case"number":case"boolean":case"string":s=i;break;default:s=Array.isArray(i)?JSON.stringify(i):i}return this._values.set(e,s),s}setValue(e,t){return super.setValue(e,t)}removeValue(e){return super.removeValue(e)}}class Kn{constructor(e,t,i){this._service=e,this._key=t,this._defaultValue=i,this.reset()}set(e){this._service.setContext(this._key,e)}reset(){"undefined"===typeof this._defaultValue?this._service.removeContext(this._key):this._service.setContext(this._key,this._defaultValue)}get(){return this._service.getContextKeyValue(this._key)}}class Yn{constructor(e){this.key=e}affectsSome(e){return e.has(this.key)}allKeysContainedIn(e){return this.affectsSome(e)}}class qn{constructor(e){this.keys=e}affectsSome(e){for(const t of this.keys)if(e.has(t))return!0;return!1}allKeysContainedIn(e){return this.keys.every((t=>e.has(t)))}}class $n{constructor(e){this.events=e}affectsSome(e){for(const t of this.events)if(t.affectsSome(e))return!0;return!1}allKeysContainedIn(e){return this.events.every((t=>t.allKeysContainedIn(e)))}}class Qn extends c.jG{constructor(e){super(),this._onDidChangeContext=this._register(new Q.fV({merge:e=>new $n(e)})),this.onDidChangeContext=this._onDidChangeContext.event,this._isDisposed=!1,this._myContextId=e}createKey(e,t){if(this._isDisposed)throw new Error("AbstractContextKeyService has been disposed");return new Kn(this,e,t)}bufferChangeEvents(e){this._onDidChangeContext.pause();try{e()}finally{this._onDidChangeContext.resume()}}createScoped(e){if(this._isDisposed)throw new Error("AbstractContextKeyService has been disposed");return new Zn(this,e)}contextMatchesRules(e){if(this._isDisposed)throw new Error("AbstractContextKeyService has been disposed");const t=this.getContextValuesContainer(this._myContextId);return!e||e.evaluate(t)}getContextKeyValue(e){if(!this._isDisposed)return this.getContextValuesContainer(this._myContextId).getValue(e)}setContext(e,t){if(this._isDisposed)return;const i=this.getContextValuesContainer(this._myContextId);i&&i.setValue(e,t)&&this._onDidChangeContext.fire(new Yn(e))}removeContext(e){this._isDisposed||this.getContextValuesContainer(this._myContextId).removeValue(e)&&this._onDidChangeContext.fire(new Yn(e))}getContext(e){return this._isDisposed?Gn.INSTANCE:this.getContextValuesContainer(function(e){for(;e;){if(e.hasAttribute(Vn)){const t=e.getAttribute(Vn);return t?parseInt(t,10):NaN}e=e.parentElement}return 0}(e))}dispose(){super.dispose(),this._isDisposed=!0}}let Xn=class extends Qn{constructor(e){super(0),this._contexts=new Map,this._lastContextId=0;const t=this._register(new jn(this._myContextId,e,this._onDidChangeContext));this._contexts.set(this._myContextId,t)}getContextValuesContainer(e){return this._isDisposed?Gn.INSTANCE:this._contexts.get(e)||Gn.INSTANCE}createChildContext(e=this._myContextId){if(this._isDisposed)throw new Error("ContextKeyService has been disposed");const t=++this._lastContextId;return this._contexts.set(t,new zn(t,this.getContextValuesContainer(e))),t}disposeContext(e){this._isDisposed||this._contexts.delete(e)}};Xn=Bn([Wn(0,Me.pG)],Xn);class Zn extends Qn{constructor(e,t){if(super(e.createChildContext()),this._parentChangeListener=this._register(new c.HE),this._parent=e,this._updateParentChangeListener(),this._domNode=t,this._domNode.hasAttribute(Vn)){let e="";this._domNode.classList&&(e=Array.from(this._domNode.classList.values()).join(", ")),console.error("Element already has context attribute"+(e?": "+e:""))}this._domNode.setAttribute(Vn,String(this._myContextId))}_updateParentChangeListener(){this._parentChangeListener.value=this._parent.onDidChangeContext((e=>{const t=this._parent.getContextValuesContainer(this._myContextId).value;var i;i=t,e.allKeysContainedIn(new Set(Object.keys(i)))||this._onDidChangeContext.fire(e)}))}dispose(){this._isDisposed||(this._parent.disposeContext(this._myContextId),this._domNode.removeAttribute(Vn),super.dispose())}getContextValuesContainer(e){return this._isDisposed?Gn.INSTANCE:this._parent.getContextValuesContainer(e)}createChildContext(e=this._myContextId){if(this._isDisposed)throw new Error("ScopedContextKeyService has been disposed");return this._parent.createChildContext(e)}disposeContext(e){this._isDisposed||this._parent.disposeContext(e)}}St.w.registerCommand("_setContext",(function(e,t,i){e.get(ie.fN).createKey(String(t),function(e){return(0,p.PI)(e,(e=>"object"===typeof e&&1===e.$mid?h.r.revive(e).toString():e instanceof h.r?e.toString():void 0))}(i))})),St.w.registerCommand({id:"getContextKeyInfo",handler:()=>[...ie.N1.all()].sort(((e,t)=>e.key.localeCompare(t.key))),metadata:{description:(0,b.kg)("getContextKeyInfo","A command that returns information about context keys"),args:[]}}),St.w.registerCommand("_generateContextKeyInfo",(function(){const e=[],t=new Set;for(const i of ie.N1.all())t.has(i.key)||(t.add(i.key),e.push(i));e.sort(((e,t)=>e.key.localeCompare(t.key))),console.log(JSON.stringify(e,void 0,2))}));var Jn=i(84040);class er{constructor(e,t){this.key=e,this.data=t,this.incoming=new Map,this.outgoing=new Map}}class tr{constructor(e){this._hashFn=e,this._nodes=new Map}roots(){const e=[];for(const t of this._nodes.values())0===t.outgoing.size&&e.push(t);return e}insertEdge(e,t){const i=this.lookupOrInsertNode(e),s=this.lookupOrInsertNode(t);i.outgoing.set(s.key,s),s.incoming.set(i.key,i)}removeNode(e){const t=this._hashFn(e);this._nodes.delete(t);for(const i of this._nodes.values())i.outgoing.delete(t),i.incoming.delete(t)}lookupOrInsertNode(e){const t=this._hashFn(e);let i=this._nodes.get(t);return i||(i=new er(t,e),this._nodes.set(t,i)),i}isEmpty(){return 0===this._nodes.size}toString(){const e=[];for(const[t,i]of this._nodes)e.push(`${t}\n\t(-> incoming)[${[...i.incoming.keys()].join(", ")}]\n\t(outgoing ->)[${[...i.outgoing.keys()].join(",")}]\n`);return e.join("\n")}findCycleSlow(){for(const[e,t]of this._nodes){const i=new Set([e]),s=this._findCycle(t,i);if(s)return s}}_findCycle(e,t){for(const[i,s]of e.outgoing){if(t.has(i))return[...t,i].join(" -> ");t.add(i);const e=this._findCycle(s,t);if(e)return e;t.delete(i)}}}var ir=i(58345);class sr extends Error{constructor(e){super("cyclic dependency between services"),this.message=e.findCycleSlow()??`UNABLE to detect cycle, dumping graph: \n${e.toString()}`}}class nr{constructor(e=new ir.a,t=!1,i,s=false){this._services=e,this._strict=t,this._parent=i,this._enableTracing=s,this._isDisposed=!1,this._servicesToMaybeDispose=new Set,this._children=new Set,this._activeInstantiations=new Set,this._services.set(ae._Y,this),this._globalGraph=s?i?._globalGraph??new tr((e=>e)):void 0}dispose(){if(!this._isDisposed){this._isDisposed=!0,(0,c.AS)(this._children),this._children.clear();for(const e of this._servicesToMaybeDispose)(0,c.Xm)(e)&&e.dispose();this._servicesToMaybeDispose.clear()}}_throwIfDisposed(){if(this._isDisposed)throw new Error("InstantiationService has been disposed")}createChild(e,t){this._throwIfDisposed();const i=this,s=new class extends nr{dispose(){i._children.delete(s),super.dispose()}}(e,this._strict,this,this._enableTracing);return this._children.add(s),t?.add(s),s}invokeFunction(e,...t){this._throwIfDisposed();const i=rr.traceInvocation(this._enableTracing,e);let s=!1;try{return e({get:e=>{if(s)throw(0,v.iH)("service accessor is only valid during the invocation of its target method");const t=this._getOrCreateServiceInstance(e,i);if(!t)throw new Error(`[invokeFunction] unknown service '${e}'`);return t}},...t)}finally{s=!0,i.stop()}}createInstance(e,...t){let i,s;return this._throwIfDisposed(),e instanceof Jn.d?(i=rr.traceCreation(this._enableTracing,e.ctor),s=this._createInstance(e.ctor,e.staticArguments.concat(t),i)):(i=rr.traceCreation(this._enableTracing,e),s=this._createInstance(e,t,i)),i.stop(),s}_createInstance(e,t=[],i){const s=ae._$.getServiceDependencies(e).sort(((e,t)=>e.index-t.index)),n=[];for(const o of s){const t=this._getOrCreateServiceInstance(o.id,i);t||this._throwIfStrict(`[createInstance] ${e.name} depends on UNKNOWN service ${o.id}.`,!1),n.push(t)}const r=s.length>0?s[0].index:t.length;if(t.length!==r){console.trace(`[createInstance] First service dependency of ${e.name} at position ${r+1} conflicts with ${t.length} static arguments`);const i=r-t.length;t=i>0?t.concat(new Array(i)):t.slice(0,r)}return Reflect.construct(e,t.concat(n))}_setCreatedServiceInstance(e,t){if(this._services.get(e)instanceof Jn.d)this._services.set(e,t);else{if(!this._parent)throw new Error("illegalState - setting UNKNOWN service instance");this._parent._setCreatedServiceInstance(e,t)}}_getServiceInstanceOrDescriptor(e){const t=this._services.get(e);return!t&&this._parent?this._parent._getServiceInstanceOrDescriptor(e):t}_getOrCreateServiceInstance(e,t){this._globalGraph&&this._globalGraphImplicitDependency&&this._globalGraph.insertEdge(this._globalGraphImplicitDependency,String(e));const i=this._getServiceInstanceOrDescriptor(e);return i instanceof Jn.d?this._safeCreateAndCacheServiceInstance(e,i,t.branch(e,!0)):(t.branch(e,!1),i)}_safeCreateAndCacheServiceInstance(e,t,i){if(this._activeInstantiations.has(e))throw new Error(`illegal state - RECURSIVELY instantiating service '${e}'`);this._activeInstantiations.add(e);try{return this._createAndCacheServiceInstance(e,t,i)}finally{this._activeInstantiations.delete(e)}}_createAndCacheServiceInstance(e,t,i){const s=new tr((e=>e.id.toString()));let n=0;const r=[{id:e,desc:t,_trace:i}],o=new Set;for(;r.length;){const t=r.pop();if(!o.has(String(t.id))){if(o.add(String(t.id)),s.lookupOrInsertNode(t),n++>1e3)throw new sr(s);for(const i of ae._$.getServiceDependencies(t.desc.ctor)){const n=this._getServiceInstanceOrDescriptor(i.id);if(n||this._throwIfStrict(`[createInstance] ${e} depends on ${i.id} which is NOT registered.`,!0),this._globalGraph?.insertEdge(String(t.id),String(i.id)),n instanceof Jn.d){const e={id:i.id,desc:n,_trace:t._trace.branch(i.id,!0)};s.insertEdge(t,e),r.push(e)}}}}for(;;){const e=s.roots();if(0===e.length){if(!s.isEmpty())throw new sr(s);break}for(const{data:t}of e){if(this._getServiceInstanceOrDescriptor(t.id)instanceof Jn.d){const e=this._createServiceInstanceWithOwner(t.id,t.desc.ctor,t.desc.staticArguments,t.desc.supportsDelayedInstantiation,t._trace);this._setCreatedServiceInstance(t.id,e)}s.removeNode(t)}}return this._getServiceInstanceOrDescriptor(e)}_createServiceInstanceWithOwner(e,t,i=[],s,n){if(this._services.get(e)instanceof Jn.d)return this._createServiceInstance(e,t,i,s,n,this._servicesToMaybeDispose);if(this._parent)return this._parent._createServiceInstanceWithOwner(e,t,i,s,n);throw new Error(`illegalState - creating UNKNOWN service instance ${t.name}`)}_createServiceInstance(e,t,i=[],s,n,r){if(s){const s=new nr(void 0,this._strict,this,this._enableTracing);s._globalGraphImplicitDependency=String(e);const o=new Map,a=new m.F6((()=>{const e=s._createInstance(t,i,n);for(const[t,i]of o){const s=e[t];if("function"===typeof s)for(const t of i)t.disposable=s.apply(e,t.listener)}return o.clear(),r.add(e),e}));return new Proxy(Object.create(null),{get(e,t){if(!a.isInitialized&&"string"===typeof t&&(t.startsWith("onDid")||t.startsWith("onWill"))){let e=o.get(t);e||(e=new X.w,o.set(t,e));return(i,s,n)=>{if(a.isInitialized)return a.value[t](i,s,n);{const t={listener:[i,s,n],disposable:void 0},r=e.push(t);return(0,c.s)((()=>{r(),t.disposable?.dispose()}))}}}if(t in e)return e[t];const i=a.value;let s=i[t];return"function"!==typeof s||(s=s.bind(i),e[t]=s),s},set:(e,t,i)=>(a.value[t]=i,!0),getPrototypeOf:e=>t.prototype})}{const e=this._createInstance(t,i,n);return r.add(e),e}}_throwIfStrict(e,t){if(t&&console.warn(e),this._strict)throw new Error(e)}}class rr{static{this.all=new Set}static{this._None=new class extends rr{constructor(){super(0,null)}stop(){}branch(){return this}}}static traceInvocation(e,t){return e?new rr(2,t.name||(new Error).stack.split("\n").slice(3,4).join("\n")):rr._None}static traceCreation(e,t){return e?new rr(1,t.name):rr._None}static{this._totals=0}constructor(e,t){this.type=e,this.name=t,this._start=Date.now(),this._dep=[]}branch(e,t){const i=new rr(3,e.toString());return this._dep.push([e,t,i]),i}stop(){const e=Date.now()-this._start;rr._totals+=e;let t=!1;const i=[`${1===this.type?"CREATE":"CALL"} ${this.name}`,`${function e(i,s){const n=[],r=new Array(i+1).join("\t");for(const[o,a,c]of s._dep)if(a&&c){t=!0,n.push(`${r}CREATES -> ${o}`);const s=e(i+1,c);s&&n.push(s)}else n.push(`${r}uses -> ${o}`);return n.join("\n")}(1,this)}`,`DONE, took ${e.toFixed(2)}ms (grand total ${rr._totals.toFixed(2)}ms)`];(e>2||t)&&rr.all.add(i.join("\n"))}}var or=i(75147);const ar=new Set([C.ny.inMemory,C.ny.vscodeSourceControl,C.ny.walkThrough,C.ny.walkThroughSnippet,C.ny.vscodeChatCodeBlock]);class cr{constructor(){this._byResource=new yt.fT,this._byOwner=new Map}set(e,t,i){let s=this._byResource.get(e);s||(s=new Map,this._byResource.set(e,s)),s.set(t,i);let n=this._byOwner.get(t);n||(n=new yt.fT,this._byOwner.set(t,n)),n.set(e,i)}get(e,t){const i=this._byResource.get(e);return i?.get(t)}delete(e,t){let i=!1,s=!1;const n=this._byResource.get(e);n&&(i=n.delete(t));const r=this._byOwner.get(t);if(r&&(s=r.delete(e)),i!==s)throw new Error("illegal state");return i&&s}values(e){return"string"===typeof e?this._byOwner.get(e)?.values()??Un.f.empty():h.r.isUri(e)?this._byResource.get(e)?.values()??Un.f.empty():Un.f.map(Un.f.concat(...this._byOwner.values()),(e=>e[1]))}}class lr{constructor(e){this.errors=0,this.infos=0,this.warnings=0,this.unknowns=0,this._data=new yt.fT,this._service=e,this._subscription=e.onMarkerChanged(this._update,this)}dispose(){this._subscription.dispose()}_update(e){for(const t of e){const e=this._data.get(t);e&&this._substract(e);const i=this._resourceStats(t);this._add(i),this._data.set(t,i)}}_resourceStats(e){const t={errors:0,warnings:0,infos:0,unknowns:0};if(ar.has(e.scheme))return t;for(const{severity:i}of this._service.read({resource:e}))i===or.cj.Error?t.errors+=1:i===or.cj.Warning?t.warnings+=1:i===or.cj.Info?t.infos+=1:t.unknowns+=1;return t}_substract(e){this.errors-=e.errors,this.warnings-=e.warnings,this.infos-=e.infos,this.unknowns-=e.unknowns}_add(e){this.errors+=e.errors,this.warnings+=e.warnings,this.infos+=e.infos,this.unknowns+=e.unknowns}}class hr{constructor(){this._onMarkerChanged=new Q.uI({delay:0,merge:hr._merge}),this.onMarkerChanged=this._onMarkerChanged.event,this._data=new cr,this._stats=new lr(this)}dispose(){this._stats.dispose(),this._onMarkerChanged.dispose()}remove(e,t){for(const i of t||[])this.changeOne(e,i,[])}changeOne(e,t,i){if((0,E.Ct)(i)){this._data.delete(t,e)&&this._onMarkerChanged.fire([t])}else{const s=[];for(const n of i){const i=hr._toMarker(e,t,n);i&&s.push(i)}this._data.set(t,e,s),this._onMarkerChanged.fire([t])}}static _toMarker(e,t,i){let{code:s,severity:n,message:r,source:o,startLineNumber:a,startColumn:c,endLineNumber:l,endColumn:h,relatedInformation:d,tags:u}=i;if(r)return a=a>0?a:1,c=c>0?c:1,l=l>=a?l:a,h=h>0?h:c,{resource:t,owner:e,code:s,severity:n,message:r,source:o,startLineNumber:a,startColumn:c,endLineNumber:l,endColumn:h,relatedInformation:d,tags:u}}changeAll(e,t){const i=[],s=this._data.values(e);if(s)for(const n of s){const t=Un.f.first(n);t&&(i.push(t.resource),this._data.delete(t.resource,e))}if((0,E.EI)(t)){const s=new yt.fT;for(const{resource:n,marker:r}of t){const t=hr._toMarker(e,n,r);if(!t)continue;const o=s.get(n);o?o.push(t):(s.set(n,[t]),i.push(n))}for(const[t,i]of s)this._data.set(t,e,i)}i.length>0&&this._onMarkerChanged.fire(i)}read(e=Object.create(null)){let{owner:t,resource:i,severities:s,take:n}=e;if((!n||n<0)&&(n=-1),t&&i){const e=this._data.get(i,t);if(e){const t=[];for(const i of e)if(hr._accept(i,s)){const e=t.push(i);if(n>0&&e===n)break}return t}return[]}if(t||i){const e=this._data.values(i??t),r=[];for(const t of e)for(const e of t)if(hr._accept(e,s)){const t=r.push(e);if(n>0&&t===n)return r}return r}{const e=[];for(const t of this._data.values())for(const i of t)if(hr._accept(i,s)){const t=e.push(i);if(n>0&&t===n)return e}return e}}static _accept(e,t){return void 0===t||(t&e.severity)===e.severity}static _merge(e){const t=new yt.fT;for(const i of e)for(const e of i)t.set(e,!0);return Array.from(t.keys())}}var dr=i(9711);class ur extends c.jG{get configurationModel(){return this._configurationModel}constructor(e){super(),this.logService=e,this._configurationModel=Tt.createEmptyModel(this.logService)}reload(){return this.resetConfigurationModel(),this.configurationModel}getConfigurationDefaultOverrides(){return{}}resetConfigurationModel(){this._configurationModel=Tt.createEmptyModel(this.logService);const e=Rt.O.as(wt.Fd.Configuration).getConfigurationProperties();this.updateConfigurationModel(Object.keys(e),e)}updateConfigurationModel(e,t){const i=this.getConfigurationDefaultOverrides();for(const s of e){const e=i[s],n=t[s];void 0!==e?this._configurationModel.setValue(s,e):n?this._configurationModel.setValue(s,n.default):this._configurationModel.removeValue(s)}}}var gr=i(87213);class pr extends c.jG{constructor(e,t=[]){super(),this.logger=new I.Dk([e,...t]),this._register(e.onDidChangeLogLevel((e=>this.setLevel(e))))}get onDidChangeLogLevel(){return this.logger.onDidChangeLogLevel}setLevel(e){this.logger.setLevel(e)}getLevel(){return this.logger.getLevel()}trace(e,...t){this.logger.trace(e,...t)}debug(e,...t){this.logger.debug(e,...t)}info(e,...t){this.logger.info(e,...t)}warn(e,...t){this.logger.warn(e,...t)}error(e,...t){this.logger.error(e,...t)}}var mr=i(72466),fr=i(97035),_r=i(44432);var vr=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Cr=function(e,t){return function(i,s){t(i,s,e)}};class Er{constructor(e){this.disposed=!1,this.model=e,this._onWillDispose=new Q.vl}get textEditorModel(){return this.model}dispose(){this.disposed=!0,this._onWillDispose.fire()}}let br=class{constructor(e){this.modelService=e}createModelReference(e){const t=this.modelService.getModel(e);return t?Promise.resolve(new c.BO(new Er(t))):Promise.reject(new Error("Model not found"))}};br=vr([Cr(0,A.IModelService)],br);class Sr{static{this.NULL_PROGRESS_RUNNER={done:()=>{},total:()=>{},worked:()=>{}}}show(){return Sr.NULL_PROGRESS_RUNNER}async showWhile(e,t){await e}}class yr{static{this.NO_OP=new me.Kz}info(e){return this.notify({severity:ge.A.Info,message:e})}warn(e){return this.notify({severity:ge.A.Warning,message:e})}error(e){return this.notify({severity:ge.A.Error,message:e})}notify(e){switch(e.severity){case ge.A.Error:console.error(e.message);break;case ge.A.Warning:console.warn(e.message);break;default:console.log(e.message)}return yr.NO_OP}prompt(e,t,i,s){return yr.NO_OP}status(e,t){return c.jG.None}}let wr=class{constructor(e){this._onWillExecuteCommand=new Q.vl,this._onDidExecuteCommand=new Q.vl,this.onDidExecuteCommand=this._onDidExecuteCommand.event,this._instantiationService=e}executeCommand(e,...t){const i=St.w.getCommand(e);if(!i)return Promise.reject(new Error(`command '${e}' not found`));try{this._onWillExecuteCommand.fire({commandId:e,args:t});const s=this._instantiationService.invokeFunction.apply(this._instantiationService,[i.handler,...t]);return this._onDidExecuteCommand.fire({commandId:e,args:t}),Promise.resolve(s)}catch(s){return Promise.reject(s)}}};wr=vr([Cr(0,ae._Y)],wr);let Rr=class extends Ht{constructor(e,t,i,s,n,r){super(e,t,i,s,n),this._cachedResolver=null,this._dynamicKeybindings=[],this._domNodeListeners=[];const o=e=>{const t=new c.Cm;t.add(U.ko(e,U.Bx.KEY_DOWN,(e=>{const t=new Xe.Z(e);this._dispatch(t,t.target)&&(t.preventDefault(),t.stopPropagation())}))),t.add(U.ko(e,U.Bx.KEY_UP,(e=>{const t=new Xe.Z(e);this._singleModifierDispatch(t,t.target)&&t.preventDefault()}))),this._domNodeListeners.push(new Lr(e,t))},a=e=>{for(let t=0;t{e.getOption(61)||o(e.getContainerDomNode())};this._register(r.onCodeEditorAdd(l)),this._register(r.onCodeEditorRemove((e=>{e.getOption(61)||a(e.getContainerDomNode())}))),r.listCodeEditors().forEach(l);const h=e=>{o(e.getContainerDomNode())};this._register(r.onDiffEditorAdd(h)),this._register(r.onDiffEditorRemove((e=>{a(e.getContainerDomNode())}))),r.listDiffEditors().forEach(h)}addDynamicKeybinding(e,t,i,s){return(0,c.qE)(St.w.registerCommand(e,i),this.addDynamicKeybindings([{keybinding:t,command:e,when:s}]))}addDynamicKeybindings(e){const t=e.map((e=>({keybinding:(0,ft.Zv)(e.keybinding,We.OS),command:e.command??null,commandArgs:e.commandArgs,when:e.when,weight1:1e3,weight2:0,extensionId:null,isBuiltinExtension:!1})));return this._dynamicKeybindings=this._dynamicKeybindings.concat(t),this.updateResolver(),(0,c.s)((()=>{for(let e=0;ethis._log(e)))}return this._cachedResolver}_documentHasFocus(){return a.G.document.hasFocus()}_toNormalizedKeybindingItems(e,t){const i=[];let s=0;for(const n of e){const e=n.when||void 0,r=n.keybinding;if(r){const o=Yt.resolveKeybinding(r,We.OS);for(const r of o)i[s++]=new Vt(r,n.command,n.commandArgs,e,t,null,!1)}else i[s++]=new Vt(void 0,n.command,n.commandArgs,e,t,null,!1)}return i}resolveKeyboardEvent(e){const t=new ft.dG(e.ctrlKey,e.shiftKey,e.altKey,e.metaKey,e.keyCode);return new Yt([t],We.OS)}};Rr=vr([Cr(0,ie.fN),Cr(1,St.d),Cr(2,Qt.k),Cr(3,me.Ot),Cr(4,I.rr),Cr(5,g.T)],Rr);class Lr extends c.jG{constructor(e,t){super(),this.domNode=e,this._register(t)}}function Tr(e){return e&&"object"===typeof e&&(!e.overrideIdentifier||"string"===typeof e.overrideIdentifier)&&(!e.resource||e.resource instanceof h.r)}let xr=class{constructor(e){this.logService=e,this._onDidChangeConfiguration=new Q.vl,this.onDidChangeConfiguration=this._onDidChangeConfiguration.event;const t=new ur(e);this._configuration=new At(t.reload(),Tt.createEmptyModel(e),Tt.createEmptyModel(e),Tt.createEmptyModel(e),Tt.createEmptyModel(e),Tt.createEmptyModel(e),new yt.fT,Tt.createEmptyModel(e),new yt.fT,e),t.dispose()}getValue(e,t){const i="string"===typeof e?e:void 0,s=Tr(e)?e:Tr(t)?t:{};return this._configuration.getValue(i,s,void 0)}updateValues(e){const t={data:this._configuration.toData()},i=[];for(const s of e){const[e,t]=s;this.getValue(e)!==t&&(this._configuration.updateValue(e,t),i.push(e))}if(i.length>0){const e=new Nt({keys:i,overrides:[]},t,this._configuration,void 0,this.logService);e.source=8,this._onDidChangeConfiguration.fire(e)}return Promise.resolve()}updateValue(e,t,i,s){return this.updateValues([[e,t]])}inspect(e,t={}){return this._configuration.inspect(e,t,void 0)}};xr=vr([Cr(0,I.rr)],xr);let kr=class{constructor(e,t,i){this.configurationService=e,this.modelService=t,this.languageService=i,this._onDidChangeConfiguration=new Q.vl,this.configurationService.onDidChangeConfiguration((e=>{this._onDidChangeConfiguration.fire({affectedKeys:e.affectedKeys,affectsConfiguration:(t,i)=>e.affectsConfiguration(i)})}))}getValue(e,t,i){const s=Et.y.isIPosition(t)?t:null,n=s?"string"===typeof i?i:void 0:"string"===typeof t?t:void 0,r=e?this.getLanguage(e,s):void 0;return"undefined"===typeof n?this.configurationService.getValue({resource:e,overrideIdentifier:r}):this.configurationService.getValue(n,{resource:e,overrideIdentifier:r})}getLanguage(e,t){const i=this.modelService.getModel(e);return i?t?i.getLanguageIdAtPosition(t.lineNumber,t.column):i.getLanguageId():this.languageService.guessLanguageIdByFilepathOrFirstLine(e)}};kr=vr([Cr(0,Me.pG),Cr(1,A.IModelService),Cr(2,Ui.L)],kr);let Ar=class{constructor(e){this.configurationService=e}getEOL(e,t){const i=this.configurationService.getValue("files.eol",{overrideIdentifier:t,resource:e});return i&&"string"===typeof i&&"auto"!==i?i:We.j9||We.zx?"\n":"\r\n"}};Ar=vr([Cr(0,Me.pG)],Ar);class Nr{static{this.SCHEME="inmemory"}constructor(){const e=h.r.from({scheme:Nr.SCHEME,authority:"model",path:"/"});this.workspace={id:Xt.cn,folders:[new Xt.mX({uri:e,name:"",index:0})]}}getWorkspace(){return this.workspace}getWorkspaceFolder(e){return e&&e.scheme===Nr.SCHEME?this.workspace.folders[0]:null}}function Ir(e,t,i){if(!t)return;if(!(e instanceof xr))return;const s=[];Object.keys(t).forEach((e=>{(0,vt.vf)(e)&&s.push([`editor.${e}`,t[e]]),i&&(0,vt.Gn)(e)&&s.push([`diffEditor.${e}`,t[e]])})),s.length>0&&e.updateValues(s)}let Or=class{constructor(e){this._modelService=e}hasPreviewHandler(){return!1}async apply(e,t){const i=Array.isArray(e)?e:_t.jN.convert(e),s=new Map;for(const o of i){if(!(o instanceof _t.cw))throw new Error("bad edit - only text edits are supported");const e=this._modelService.getModel(o.resource);if(!e)throw new Error("bad edit - model not found");if("number"===typeof o.versionId&&e.getVersionId()!==o.versionId)throw new Error("bad state - model changed in the meantime");let t=s.get(e);t||(t=[],s.set(e,t)),t.push(Ct.k.replaceMove(T.Q.lift(o.textEdit.range),o.textEdit.text))}let n=0,r=0;for(const[o,a]of s)o.pushStackElement(),o.pushEditOperations([],a,(()=>[])),o.pushStackElement(),r+=1,n+=a.length;return{ariaSummary:l.GP(Zt.tu.bulkEditServiceSummary,n,r),isApplied:n>0}}};Or=vr([Cr(0,A.IModelService)],Or);let Dr=class extends ot{constructor(e,t){super(e),this._codeEditorService=t}showContextView(e,t,i){if(!t){const e=this._codeEditorService.getFocusedCodeEditor()||this._codeEditorService.getActiveCodeEditor();e&&(t=e.getContainerDomNode())}return super.showContextView(e,t,i)}};Dr=vr([Cr(0,ce),Cr(1,g.T)],Dr);class Mr extends ti.LanguageService{constructor(){super()}}let Pr=class extends xi{constructor(e,t,i,s,n,r){super(e,t,i,s,n,r),this.configure({blockMouse:!1})}};Pr=vr([Cr(0,Qt.k),Cr(1,me.Ot),Cr(2,Oe.l),Cr(3,De.b),Cr(4,ni.ez),Cr(5,ie.fN)],Pr);const Fr={amdModuleId:"vs/editor/common/services/editorSimpleWorker",esmModuleLocation:void 0,label:"editorWorkerService"};let Ur=class extends j{constructor(e,t,i,s,n){super(Fr,e,t,i,s,n)}};Ur=vr([Cr(0,A.IModelService),Cr(1,N.ITextResourceConfigurationService),Cr(2,I.rr),Cr(3,x.JZ),Cr(4,D.ILanguageFeaturesService)],Ur);var Hr;(0,se.v)(I.rr,class extends pr{constructor(){super(new I.Cr)}},0),(0,se.v)(Me.pG,xr,0),(0,se.v)(N.ITextResourceConfigurationService,kr,0),(0,se.v)(N.ITextResourcePropertiesService,Ar,0),(0,se.v)(Xt.VR,Nr,0),(0,se.v)(qt.L,class{getUriLabel(e,t){return"file"===e.scheme?e.fsPath:e.path}getUriBasenameLabel(e){return(0,Jt.P8)(e)}},0),(0,se.v)(Qt.k,class{publicLog2(){}},0),(0,se.v)(pe.X,class{async confirm(e){return{confirmed:this.doConfirm(e.message,e.detail),checkboxChecked:!1}}doConfirm(e,t){let i=e;return t&&(i=i+"\n\n"+t),a.G.confirm(i)}async prompt(e){let t;if(this.doConfirm(e.message,e.detail)){const i=[...e.buttons??[]];e.cancelButton&&"string"!==typeof e.cancelButton&&"boolean"!==typeof e.cancelButton&&i.push(e.cancelButton),t=await(i[0]?.run({checkboxChecked:!1}))}return{result:t}}async error(e,t){await this.prompt({type:ge.A.Error,message:e,detail:t})}},0),(0,se.v)(fr.k,class{constructor(){this.isExtensionDevelopment=!1,this.isBuilt=!1}},0),(0,se.v)(me.Ot,yr,0),(0,se.v)(or.DR,hr,0),(0,se.v)(Ui.L,Mr,0),(0,se.v)(Ln.L,Rn.Sx,0),(0,se.v)(A.IModelService,Wi.ModelService,0),(0,se.v)(Bi.IMarkerDecorationsService,Hi.MarkerDecorationsService,0),(0,se.v)(ie.fN,Xn,0),(0,se.v)($t.G5,class{withProgress(e,t,i){return t({report:()=>{}})}},0),(0,se.v)($t.N8,Sr,0),(0,se.v)(dr.CS,dr.pc,0),(0,se.v)(Fi.IEditorWorkerService,Ur,0),(0,se.v)(_t.nu,Or,0),(0,se.v)(ei.L,class{constructor(){this._neverEmitter=new Q.vl,this.onDidChangeTrust=this._neverEmitter.event}isWorkspaceTrusted(){return!0}},0),(0,se.v)(bt.ITextModelService,br,0),(0,se.v)(Ve.j,kn,0),(0,se.v)(Ns.PE,Ns.aG,0),(0,se.v)(St.d,wr,0),(0,se.v)(De.b,Rr,0),(0,se.v)(zi.GK,Sn,0),(0,se.v)(Oe.l,Dr,0),(0,se.v)(Ue.C,Pi,0),(0,se.v)(Fn.h,Pn,0),(0,se.v)(Oe.Z,Pr,0),(0,se.v)(ni.ez,Nn.$,0),(0,se.v)(gr.Nt,class{async playSignal(e,t){}},0),(0,se.v)(_r.ITreeSitterParserService,class{getParseResult(e){}},0),function(e){const t=new ir.a;for(const[o,a]of(0,se.N)())t.set(o,a);const i=new nr(t,!0);t.set(ae._Y,i),e.get=function(e){s||r({});const n=t.get(e);if(!n)throw new Error("Missing service "+e);return n instanceof Jn.d?i.invokeFunction((t=>t.get(e))):n};let s=!1;const n=new Q.vl;function r(e){if(s)return i;s=!0;for(const[i,s]of(0,se.N)())t.get(i)||t.set(i,s);for(const i in e)if(e.hasOwnProperty(i)){const s=(0,ae.u1)(i);t.get(s)instanceof Jn.d&&t.set(s,e[i])}const r=(0,mr.T)();for(const t of r)try{i.createInstance(t)}catch(o){(0,v.dz)(o)}return n.fire(),i}e.initialize=r,e.withServices=function(e){if(s)return e();const t=new c.Cm,i=t.add(n.event((()=>{i.dispose(),t.add(e())})));return t}}(Hr||(Hr={}));class Br extends ${constructor(e,t){super({amdModuleId:Fr.amdModuleId,esmModuleLocation:Fr.esmModuleLocation,label:t.label},t.keepIdleModels||!1,e),this._foreignModuleId=t.moduleId,this._foreignModuleCreateData=t.createData||null,this._foreignModuleHost=t.host||null,this._foreignProxy=null}fhr(e,t){if(!this._foreignModuleHost||"function"!==typeof this._foreignModuleHost[e])return Promise.reject(new Error("Missing method "+e+" or missing main thread foreign host."));try{return Promise.resolve(this._foreignModuleHost[e].apply(this._foreignModuleHost,t))}catch(i){return Promise.reject(i)}}_getForeignProxy(){return this._foreignProxy||(this._foreignProxy=this._getProxy().then((e=>{const t=this._foreignModuleHost?(0,p.V0)(this._foreignModuleHost):[];return e.$loadForeignModule(this._foreignModuleId,this._foreignModuleCreateData,t).then((t=>{this._foreignModuleCreateData=null;const i=(t,i)=>e.$fmr(t,i),s=(e,t)=>function(){const i=Array.prototype.slice.call(arguments,0);return t(e,i)},n={};for(const e of t)n[e]=s(e,i);return n}))}))),this._foreignProxy}getProxy(){return this._getForeignProxy()}withSyncedResources(e){return this.workerWithSyncedResources(e).then((e=>this.getProxy()))}}var Wr=i(79027),Vr=i(74196),zr=i(23452),Gr=i(62083),jr=i(83941),Kr=i(20788),Yr=i(16223),qr=i(35015),$r=i(87469),Qr=i(35600),Xr=i(92896);function Zr(e){return!function(e){return Array.isArray(e)}(e)}function Jr(e){return"string"===typeof e}function eo(e){return!Jr(e)}function to(e){return!e}function io(e,t){return e.ignoreCase&&t?t.toLowerCase():t}function so(e){return e.replace(/[&<>'"_]/g,"-")}function no(e,t){return new Error(`${e.languageId}: ${t}`)}function ro(e,t,i,s,n){let r=null;return t.replace(/\$((\$)|(#)|(\d\d?)|[sS](\d\d?)|@(\w+))/g,(function(t,o,a,c,l,h,d,u,g){return to(a)?to(c)?!to(l)&&l0;){const t=e.tokenizer[i];if(t)return t;const s=i.lastIndexOf(".");i=s<0?null:i.substr(0,s)}return null}var ao,co=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},lo=function(e,t){return function(i,s){t(i,s,e)}};class ho{static{this._INSTANCE=new ho(5)}static create(e,t){return this._INSTANCE.create(e,t)}constructor(e){this._maxCacheDepth=e,this._entries=Object.create(null)}create(e,t){if(null!==e&&e.depth>=this._maxCacheDepth)return new uo(e,t);let i=uo.getStackElementId(e);i.length>0&&(i+="|"),i+=t;let s=this._entries[i];return s||(s=new uo(e,t),this._entries[i]=s,s)}}class uo{constructor(e,t){this.parent=e,this.state=t,this.depth=(this.parent?this.parent.depth:0)+1}static getStackElementId(e){let t="";for(;null!==e;)t.length>0&&(t+="|"),t+=e.state,e=e.parent;return t}static _equals(e,t){for(;null!==e&&null!==t;){if(e===t)return!0;if(e.state!==t.state)return!1;e=e.parent,t=t.parent}return null===e&&null===t}equals(e){return uo._equals(this,e)}push(e){return ho.create(this,e)}pop(){return this.parent}popall(){let e=this;for(;e.parent;)e=e.parent;return e}switchTo(e){return ho.create(this.parent,e)}}class go{constructor(e,t){this.languageId=e,this.state=t}equals(e){return this.languageId===e.languageId&&this.state.equals(e.state)}clone(){return this.state.clone()===this.state?this:new go(this.languageId,this.state)}}class po{static{this._INSTANCE=new po(5)}static create(e,t){return this._INSTANCE.create(e,t)}constructor(e){this._maxCacheDepth=e,this._entries=Object.create(null)}create(e,t){if(null!==t)return new mo(e,t);if(null!==e&&e.depth>=this._maxCacheDepth)return new mo(e,t);const i=uo.getStackElementId(e);let s=this._entries[i];return s||(s=new mo(e,null),this._entries[i]=s,s)}}class mo{constructor(e,t){this.stack=e,this.embeddedLanguageData=t}clone(){return(this.embeddedLanguageData?this.embeddedLanguageData.clone():null)===this.embeddedLanguageData?this:po.create(this.stack,this.embeddedLanguageData)}equals(e){return e instanceof mo&&(!!this.stack.equals(e.stack)&&(null===this.embeddedLanguageData&&null===e.embeddedLanguageData||null!==this.embeddedLanguageData&&null!==e.embeddedLanguageData&&this.embeddedLanguageData.equals(e.embeddedLanguageData)))}}class fo{constructor(){this._tokens=[],this._languageId=null,this._lastTokenType=null,this._lastTokenLanguage=null}enterLanguage(e){this._languageId=e}emit(e,t){this._lastTokenType===t&&this._lastTokenLanguage===this._languageId||(this._lastTokenType=t,this._lastTokenLanguage=this._languageId,this._tokens.push(new Gr.ou(e,t,this._languageId)))}nestedLanguageTokenize(e,t,i,s){const n=i.languageId,r=i.state,o=Gr.dG.get(n);if(!o)return this.enterLanguage(n),this.emit(s,""),r;const a=o.tokenize(e,t,r);if(0!==s)for(const c of a.tokens)this._tokens.push(new Gr.ou(c.offset+s,c.type,c.language));else this._tokens=this._tokens.concat(a.tokens);return this._lastTokenType=null,this._lastTokenLanguage=null,this._languageId=null,a.endState}finalize(e){return new Gr.$M(this._tokens,e)}}class _o{constructor(e,t){this._languageService=e,this._theme=t,this._prependTokens=null,this._tokens=[],this._currentLanguageId=0,this._lastTokenMetadata=0}enterLanguage(e){this._currentLanguageId=this._languageService.languageIdCodec.encodeLanguageId(e)}emit(e,t){const i=1024|this._theme.match(this._currentLanguageId,t);this._lastTokenMetadata!==i&&(this._lastTokenMetadata=i,this._tokens.push(e),this._tokens.push(i))}static _merge(e,t,i){const s=null!==e?e.length:0,n=t.length,r=null!==i?i.length:0;if(0===s&&0===n&&0===r)return new Uint32Array(0);if(0===s&&0===n)return i;if(0===n&&0===r)return e;const o=new Uint32Array(s+n+r);null!==e&&o.set(e);for(let a=0;a{if(r)return;let t=!1;for(let i=0,s=e.changedLanguages.length;i{e.affectsConfiguration("editor.maxTokenizationLineLength")&&(this._maxTokenizationLineLength=this._configurationService.getValue("editor.maxTokenizationLineLength",{overrideIdentifier:this._languageId}))})))}getLoadStatus(){const e=[];for(const t in this._embeddedLanguages){const i=Gr.dG.get(t);if(i){if(i instanceof ao){const t=i.getLoadStatus();!1===t.loaded&&e.push(t.promise)}}else Gr.dG.isResolved(t)||e.push(Gr.dG.getOrCreate(t))}return 0===e.length?{loaded:!0}:{loaded:!1,promise:Promise.all(e).then((e=>{}))}}getInitialState(){const e=ho.create(null,this._lexer.start);return po.create(e,null)}tokenize(e,t,i){if(e.length>=this._maxTokenizationLineLength)return(0,Kr.$H)(this._languageId,i);const s=new fo,n=this._tokenize(e,t,i,s);return s.finalize(n)}tokenizeEncoded(e,t,i){if(e.length>=this._maxTokenizationLineLength)return(0,Kr.Lh)(this._languageService.languageIdCodec.encodeLanguageId(this._languageId),i);const s=new _o(this._languageService,this._standaloneThemeService.getColorTheme().tokenTheme),n=this._tokenize(e,t,i,s);return s.finalize(n)}_tokenize(e,t,i,s){return i.embeddedLanguageData?this._nestedTokenize(e,t,i,0,s):this._myTokenize(e,t,i,0,s)}_findLeavingNestedLanguageOffset(e,t){let i=this._lexer.tokenizer[t.stack.state];if(!i&&(i=oo(this._lexer,t.stack.state),!i))throw no(this._lexer,"tokenizer state is not defined: "+t.stack.state);let s=-1,n=!1;for(const r of i){if(!eo(r.action)||"@pop"!==r.action.nextEmbedded)continue;n=!0;let i=r.resolveRegex(t.stack.state);const o=i.source;if("^(?:"===o.substr(0,4)&&")"===o.substr(o.length-1,1)){const e=(i.ignoreCase?"i":"")+(i.unicode?"u":"");i=new RegExp(o.substr(4,o.length-5),e)}const a=e.search(i);-1===a||0!==a&&r.matchOnlyAtLineStart||(-1===s||a0&&n.nestedLanguageTokenize(o,!1,i.embeddedLanguageData,s);const a=e.substring(r);return this._myTokenize(a,t,i,s+r,n)}_safeRuleName(e){return e?e.name:"(unknown)"}_myTokenize(e,t,i,s,n){n.enterLanguage(this._languageId);const r=e.length,o=t&&this._lexer.includeLF?e+"\n":e,a=o.length;let c=i.embeddedLanguageData,l=i.stack,h=0,d=null,u=!0;for(;u||h=a)break;u=!1;let e=this._lexer.tokenizer[_];if(!e&&(e=oo(this._lexer,_),!e))throw no(this._lexer,"tokenizer state is not defined: "+_);const t=o.substr(h);for(const i of e)if((0===h||!i.matchOnlyAtLineStart)&&(v=t.match(i.resolveRegex(_)),v)){C=v[0],E=i.action;break}}if(v||(v=[""],C=""),E||(h=this._lexer.maxStack)throw no(this._lexer,"maximum tokenizer stack size reached: ["+l.state+","+l.parent.state+",...]");l=l.push(_)}else if("@pop"===E.next){if(l.depth<=1)throw no(this._lexer,"trying to pop an empty stack in rule: "+this._safeRuleName(b));l=l.pop()}else if("@popall"===E.next)l=l.popall();else{let e=ro(this._lexer,E.next,C,v,_);if("@"===e[0]&&(e=e.substr(1)),!oo(this._lexer,e))throw no(this._lexer,"trying to set a next state '"+e+"' that is undefined in rule: "+this._safeRuleName(b));l=l.push(e)}}E.log&&"string"===typeof E.log&&(g=this._lexer,p=this._lexer.languageId+": "+ro(this._lexer,E.log,C,v,_),console.log(`${g.languageId}: ${p}`))}if(null===y)throw no(this._lexer,"lexer rule has no well-defined action in rule: "+this._safeRuleName(b));const w=i=>{const r=this._languageService.getLanguageIdByLanguageName(i)||this._languageService.getLanguageIdByMimeType(i)||i,o=this._getNestedEmbeddedLanguageData(r);if(h0)throw no(this._lexer,"groups cannot be nested: "+this._safeRuleName(b));if(v.length!==y.length+1)throw no(this._lexer,"matched number of groups does not match the number of actions in rule: "+this._safeRuleName(b));let e=0;for(let t=1;te});class bo{static colorizeElement(e,t,i,s){const n=(s=s||{}).theme||"vs",r=s.mimeType||i.getAttribute("lang")||i.getAttribute("data-lang");if(!r)return console.error("Mode not detected"),Promise.resolve();const o=t.getLanguageIdByMimeType(r)||r;e.setTheme(n);const a=i.firstChild?i.firstChild.nodeValue:"";i.className+=" "+n;return this.colorize(t,a||"",o,s).then((e=>{const t=Eo?.createHTML(e)??e;i.innerHTML=t}),(e=>console.error(e)))}static async colorize(e,t,i,s){const n=e.languageIdCodec;let r=4;s&&"number"===typeof s.tabSize&&(r=s.tabSize),l.LU(t)&&(t=t.substr(1));const o=l.uz(t);if(!e.isRegisteredLanguageId(i))return So(o,r,n);const a=await Gr.dG.getOrCreate(i);return a?function(e,t,i,s){return new Promise(((n,r)=>{const o=()=>{const a=function(e,t,i,s){let n=[],r=i.getInitialState();for(let o=0,a=e.length;o"),r=c.endState}return n.join("")}(e,t,i,s);if(i instanceof vo){const e=i.getLoadStatus();if(!1===e.loaded)return void e.promise.then(o,r)}n(a)};o()}))}(o,r,a,n):So(o,r,n)}static colorizeLine(e,t,i,s,n=4){const r=Xr.qL.isBasicASCII(e,t),o=Xr.qL.containsRTL(e,r,i);return(0,Qr.Md)(new Qr.zL(!1,!0,e,!1,r,o,0,s,[],n,0,0,0,0,-1,"none",!1,!1,null)).html}static colorizeModelLine(e,t,i=4){const s=e.getLineContent(t);e.tokenization.forceTokenization(t);const n=e.tokenization.getLineTokens(t).inflate();return this.colorizeLine(s,e.mightContainNonBasicASCII(),e.mightContainRTL(),n,i)}}function So(e,t,i){let s=[];const n=new Uint32Array(2);n[0]=0,n[1]=33587200;for(let r=0,o=e.length;r")}return s.join("")}var yo=i(29611),wo=i(4360),Ro=i(42904),Lo=i(48196),To=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xo=function(e,t){return function(i,s){t(i,s,e)}};let ko=0,Ao=!1;let No=class extends n.x{constructor(e,t,i,s,n,r,o,c,l,h,d,u,g){const p={...t};p.ariaLabel=p.ariaLabel||Zt.vp.editorViewAccessibleLabel,super(e,p,{},i,s,n,r,l,h,d,u,g),this._standaloneKeybindingService=c instanceof Rr?c:null,function(e){if(!e){if(Ao)return;Ao=!0}ze.vr(e||a.G.document.body)}(p.ariaContainerElement),(0,Ro.MW)(((e,t)=>i.createInstance(Ie.fO,e,t,{}))),(0,Lo.e)(o)}addCommand(e,t,i){if(!this._standaloneKeybindingService)return console.warn("Cannot add command because the editor is configured with an unrecognized KeybindingService"),null;const s="DYNAMIC_"+ ++ko,n=ie.M$.deserialize(i);return this._standaloneKeybindingService.addDynamicKeybinding(s,e,t,n),s}createContextKey(e,t){return this._contextKeyService.createKey(e,t)}addAction(e){if("string"!==typeof e.id||"string"!==typeof e.label||"function"!==typeof e.run)throw new Error("Invalid action descriptor, `id`, `label` and `run` are required properties!");if(!this._standaloneKeybindingService)return console.warn("Cannot add keybinding because the editor is configured with an unrecognized KeybindingService"),c.jG.None;const t=e.id,i=e.label,s=ie.M$.and(ie.M$.equals("editorId",this.getId()),ie.M$.deserialize(e.precondition)),n=e.keybindings,r=ie.M$.and(s,ie.M$.deserialize(e.keybindingContext)),o=e.contextMenuGroupId||null,a=e.contextMenuOrder||0,l=(t,...i)=>Promise.resolve(e.run(this,...i)),h=new c.Cm,d=this.getId()+":"+t;if(h.add(St.w.registerCommand(d,l)),o){const e={command:{id:d,title:i},when:s,group:o,order:a};h.add(ni.ZG.appendMenuItem(ni.D8.EditorContext,e))}if(Array.isArray(n))for(const c of n)h.add(this._standaloneKeybindingService.addDynamicKeybinding(d,c,l,r));const u=new yo.f(d,i,i,void 0,s,((...t)=>Promise.resolve(e.run(this,...t))),this._contextKeyService);return this._actions.set(t,u),h.add((0,c.s)((()=>{this._actions.delete(t)}))),h}_triggerCommand(e,t){if(this._codeEditorService instanceof oe)try{this._codeEditorService.setActiveCodeEditor(this),super._triggerCommand(e,t)}finally{this._codeEditorService.setActiveCodeEditor(null)}else super._triggerCommand(e,t)}};No=To([xo(2,ae._Y),xo(3,g.T),xo(4,St.d),xo(5,ie.fN),xo(6,Ie.TN),xo(7,De.b),xo(8,Z.Gy),xo(9,me.Ot),xo(10,Ve.j),xo(11,x.JZ),xo(12,D.ILanguageFeaturesService)],No);let Io=class extends No{constructor(e,t,i,s,n,r,o,a,c,l,h,d,u,g,p,m){const f={...t};Ir(h,f,!1);const _=c.registerEditorContainer(e);"string"===typeof f.theme&&c.setTheme(f.theme),"undefined"!==typeof f.autoDetectHighContrast&&c.setAutoDetectHighContrast(Boolean(f.autoDetectHighContrast));const v=f.model;let C;if(delete f.model,super(e,f,i,s,n,r,o,a,c,l,d,p,m),this._configurationService=h,this._standaloneThemeService=c,this._register(_),"undefined"===typeof v){const e=g.getLanguageIdByMimeType(f.language)||f.language||jr.vH;C=Do(u,g,f.value||"",e,void 0),this._ownsModel=!0}else C=v,this._ownsModel=!1;if(this._attachModel(C),C){const e={oldModelUrl:null,newModelUrl:C.uri};this._onDidChangeModel.fire(e)}}dispose(){super.dispose()}updateOptions(e){Ir(this._configurationService,e,!1),"string"===typeof e.theme&&this._standaloneThemeService.setTheme(e.theme),"undefined"!==typeof e.autoDetectHighContrast&&this._standaloneThemeService.setAutoDetectHighContrast(Boolean(e.autoDetectHighContrast)),super.updateOptions(e)}_postDetachModelCleanup(e){super._postDetachModelCleanup(e),e&&this._ownsModel&&(e.dispose(),this._ownsModel=!1)}};Io=To([xo(2,ae._Y),xo(3,g.T),xo(4,St.d),xo(5,ie.fN),xo(6,Ie.TN),xo(7,De.b),xo(8,Ln.L),xo(9,me.Ot),xo(10,Me.pG),xo(11,Ve.j),xo(12,A.IModelService),xo(13,Ui.L),xo(14,x.JZ),xo(15,D.ILanguageFeaturesService)],Io);let Oo=class extends wo.T{constructor(e,t,i,s,n,r,o,a,c,l,h,d){const u={...t};Ir(a,u,!0);const g=r.registerEditorContainer(e);"string"===typeof u.theme&&r.setTheme(u.theme),"undefined"!==typeof u.autoDetectHighContrast&&r.setAutoDetectHighContrast(Boolean(u.autoDetectHighContrast)),super(e,u,{},s,i,n,d,l),this._configurationService=a,this._standaloneThemeService=r,this._register(g)}dispose(){super.dispose()}updateOptions(e){Ir(this._configurationService,e,!0),"string"===typeof e.theme&&this._standaloneThemeService.setTheme(e.theme),"undefined"!==typeof e.autoDetectHighContrast&&this._standaloneThemeService.setAutoDetectHighContrast(Boolean(e.autoDetectHighContrast)),super.updateOptions(e)}_createInnerEditor(e,t,i){return e.createInstance(No,t,i)}getOriginalEditor(){return super.getOriginalEditor()}getModifiedEditor(){return super.getModifiedEditor()}addCommand(e,t,i){return this.getModifiedEditor().addCommand(e,t,i)}createContextKey(e,t){return this.getModifiedEditor().createContextKey(e,t)}addAction(e){return this.getModifiedEditor().addAction(e)}};function Do(e,t,i,s,n){if(i=i||"",!s){const s=i.indexOf("\n");let r=i;return-1!==s&&(r=i.substring(0,s)),Mo(e,i,t.createByFilepathOrFirstLine(n||null,r),n)}return Mo(e,i,t.createById(s),n)}function Mo(e,t,i,s){return e.createModel(t,i,s)}Oo=To([xo(2,ae._Y),xo(3,ie.fN),xo(4,g.T),xo(5,Ln.L),xo(6,me.Ot),xo(7,Me.pG),xo(8,Oe.Z),xo(9,$t.N8),xo(10,Fn.h),xo(11,gr.Nt)],Oo);var Po=i(41127),Fo=i(46041),Uo=i(49154),Ho=i(49353),Bo=i(92368),Wo=i(74444),Vo=i(75326),zo=i(60002),Go=i(38844),jo=i(65644),Ko=i(25791),Yo=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},qo=function(e,t){return function(i,s){t(i,s,e)}};class $o{constructor(e,t){this.viewModel=e,this.deltaScrollVertical=t}getId(){return this.viewModel}}let Qo=class extends c.jG{constructor(e,t,i,s,n){super(),this._container=e,this._overflowWidgetsDomNode=t,this._workbenchUIElementFactory=i,this._instantiationService=s,this._viewModel=(0,Uo.FY)(this,void 0),this._collapsed=(0,Bs.un)(this,(e=>this._viewModel.read(e)?.collapsed.read(e))),this._editorContentHeight=(0,Uo.FY)(this,500),this.contentHeight=(0,Bs.un)(this,(e=>(this._collapsed.read(e)?0:this._editorContentHeight.read(e))+this._outerEditorHeight)),this._modifiedContentWidth=(0,Uo.FY)(this,0),this._modifiedWidth=(0,Uo.FY)(this,0),this._originalContentWidth=(0,Uo.FY)(this,0),this._originalWidth=(0,Uo.FY)(this,0),this.maxScroll=(0,Bs.un)(this,(e=>{const t=this._modifiedContentWidth.read(e)-this._modifiedWidth.read(e),i=this._originalContentWidth.read(e)-this._originalWidth.read(e);return t>i?{maxScroll:t,width:this._modifiedWidth.read(e)}:{maxScroll:i,width:this._originalWidth.read(e)}})),this._elements=(0,U.h)("div.multiDiffEntry",[(0,U.h)("div.header@header",[(0,U.h)("div.header-content",[(0,U.h)("div.collapse-button@collapseButton"),(0,U.h)("div.file-path",[(0,U.h)("div.title.modified.show-file-icons@primaryPath",[]),(0,U.h)("div.status.deleted@status",["R"]),(0,U.h)("div.title.original.show-file-icons@secondaryPath",[])]),(0,U.h)("div.actions@actions")])]),(0,U.h)("div.editorParent",[(0,U.h)("div.editorContainer@editor")])]),this.editor=this._register(this._instantiationService.createInstance(wo.T,this._elements.editor,{overflowWidgetsDomNode:this._overflowWidgetsDomNode},{})),this.isModifedFocused=(0,Go.Ud)(this.editor.getModifiedEditor()).isFocused,this.isOriginalFocused=(0,Go.Ud)(this.editor.getOriginalEditor()).isFocused,this.isFocused=(0,Bs.un)(this,(e=>this.isModifedFocused.read(e)||this.isOriginalFocused.read(e))),this._resourceLabel=this._workbenchUIElementFactory.createResourceLabel?this._register(this._workbenchUIElementFactory.createResourceLabel(this._elements.primaryPath)):void 0,this._resourceLabel2=this._workbenchUIElementFactory.createResourceLabel?this._register(this._workbenchUIElementFactory.createResourceLabel(this._elements.secondaryPath)):void 0,this._dataStore=this._register(new c.Cm),this._headerHeight=40,this._lastScrollTop=-1,this._isSettingScrollTop=!1;const r=new Es.$(this._elements.collapseButton,{});this._register((0,Bs.fm)((e=>{r.element.className="",r.icon=this._collapsed.read(e)?di.W.chevronRight:di.W.chevronDown}))),this._register(r.onDidClick((()=>{this._viewModel.get()?.collapsed.set(!this._collapsed.get(),void 0)}))),this._register((0,Bs.fm)((e=>{this._elements.editor.style.display=this._collapsed.read(e)?"none":"block"}))),this._register(this.editor.getModifiedEditor().onDidLayoutChange((e=>{const t=this.editor.getModifiedEditor().getLayoutInfo().contentWidth;this._modifiedWidth.set(t,void 0)}))),this._register(this.editor.getOriginalEditor().onDidLayoutChange((e=>{const t=this.editor.getOriginalEditor().getLayoutInfo().contentWidth;this._originalWidth.set(t,void 0)}))),this._register(this.editor.onDidContentSizeChange((e=>{(0,Uo.YY)((t=>{this._editorContentHeight.set(e.contentHeight,t),this._modifiedContentWidth.set(this.editor.getModifiedEditor().getContentWidth(),t),this._originalContentWidth.set(this.editor.getOriginalEditor().getContentWidth(),t)}))}))),this._register(this.editor.getOriginalEditor().onDidScrollChange((e=>{if(this._isSettingScrollTop)return;if(!e.scrollTopChanged||!this._data)return;const t=e.scrollTop-this._lastScrollTop;this._data.deltaScrollVertical(t)}))),this._register((0,Bs.fm)((e=>{const t=this._viewModel.read(e)?.isActive.read(e);this._elements.root.classList.toggle("active",t)}))),this._container.appendChild(this._elements.root),this._outerEditorHeight=this._headerHeight,this._contextKeyService=this._register(n.createScoped(this._elements.actions));const o=this._register(this._instantiationService.createChild(new ir.a([ie.fN,this._contextKeyService])));this._register(o.createInstance(jo.m,this._elements.actions,ni.D8.MultiDiffEditorFileToolbar,{actionRunner:this._register(new Ko.I((()=>this._viewModel.get()?.modifiedUri))),menuOptions:{shouldForwardArgs:!0},toolbarOptions:{primaryGroup:e=>e.startsWith("navigation")},actionViewItemProvider:(e,t)=>(0,si.rN)(o,e,t)}))}setScrollLeft(e){this._modifiedContentWidth.get()-this._modifiedWidth.get()>this._originalContentWidth.get()-this._originalWidth.get()?this.editor.getModifiedEditor().setScrollLeft(e):this.editor.getOriginalEditor().setScrollLeft(e)}setData(e){function t(e){return{...e,scrollBeyondLastLine:!1,hideUnchangedRegions:{enabled:!0},scrollbar:{vertical:"hidden",horizontal:"hidden",handleMouseWheel:!1,useShadows:!1},renderOverviewRuler:!1,fixedOverflowWidgets:!0,overviewRulerBorder:!1}}if(this._data=e,!e)return void(0,Uo.YY)((e=>{this._viewModel.set(void 0,e),this.editor.setDiffModel(null,e),this._dataStore.clear()}));const i=e.viewModel.documentDiffItem;if((0,Uo.YY)((s=>{this._resourceLabel?.setUri(e.viewModel.modifiedUri??e.viewModel.originalUri,{strikethrough:void 0===e.viewModel.modifiedUri});let n=!1,r=!1,o=!1,a="";e.viewModel.modifiedUri&&e.viewModel.originalUri&&e.viewModel.modifiedUri.path!==e.viewModel.originalUri.path?(a="R",n=!0):e.viewModel.modifiedUri?e.viewModel.originalUri||(a="A",o=!0):(a="D",r=!0),this._elements.status.classList.toggle("renamed",n),this._elements.status.classList.toggle("deleted",r),this._elements.status.classList.toggle("added",o),this._elements.status.innerText=a,this._resourceLabel2?.setUri(n?e.viewModel.originalUri:void 0,{strikethrough:!0}),this._dataStore.clear(),this._viewModel.set(e.viewModel,s),this.editor.setDiffModel(e.viewModel.diffEditorViewModelRef,s),this.editor.updateOptions(t(i.options??{}))})),i.onOptionsDidChange&&this._dataStore.add(i.onOptionsDidChange((()=>{this.editor.updateOptions(t(i.options??{}))}))),e.viewModel.isAlive.recomputeInitiallyAndOnChange(this._dataStore,(e=>{e||this.setData(void 0)})),e.viewModel.documentDiffItem.contextKeys)for(const[s,n]of Object.entries(e.viewModel.documentDiffItem.contextKeys))this._contextKeyService.createKey(s,n)}render(e,t,i,s){this._elements.root.style.visibility="visible",this._elements.root.style.top=`${e.start}px`,this._elements.root.style.height=`${e.length}px`,this._elements.root.style.width=`${t}px`,this._elements.root.style.position="absolute";const n=e.length-this._headerHeight,r=Math.max(0,Math.min(s.start-e.start,n));this._elements.header.style.transform=`translateY(${r}px)`,(0,Uo.YY)((i=>{this.editor.layout({width:t-16-2,height:e.length-this._outerEditorHeight})}));try{this._isSettingScrollTop=!0,this._lastScrollTop=i,this.editor.getOriginalEditor().setScrollTop(i)}finally{this._isSettingScrollTop=!1}this._elements.header.classList.toggle("shadow",r>0||i>0),this._elements.header.classList.toggle("collapsed",r===n)}hide(){this._elements.root.style.top="-100000px",this._elements.root.style.visibility="hidden"}};Qo=Yo([qo(3,ae._Y),qo(4,ie.fN)],Qo);class Xo{constructor(e){this._create=e,this._unused=new Set,this._used=new Set,this._itemData=new Map}getUnusedObj(e){let t;if(0===this._unused.size)t=this._create(e),this._itemData.set(t,e);else{const i=[...this._unused.values()];t=i.find((t=>this._itemData.get(t).getId()===e.getId()))??i[0],this._unused.delete(t),this._itemData.set(t,e),t.setData(e)}return this._used.add(t),{object:t,dispose:()=>{this._used.delete(t),this._unused.size>5?t.dispose():this._unused.add(t)}}}dispose(){for(const e of this._used)e.dispose();for(const e of this._unused)e.dispose();this._used.clear(),this._unused.clear()}}var Zo=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Jo=function(e,t){return function(i,s){t(i,s,e)}};let ea=class extends c.jG{constructor(e,t,i,s,n,r){super(),this._element=e,this._dimension=t,this._viewModel=i,this._workbenchUIElementFactory=s,this._parentContextKeyService=n,this._parentInstantiationService=r,this._scrollableElements=(0,U.h)("div.scrollContent",[(0,U.h)("div@content",{style:{overflow:"hidden"}}),(0,U.h)("div.monaco-editor@overflowWidgetsDomNode",{})]),this._scrollable=this._register(new Ho.yE({forceIntegerValues:!1,scheduleAtNextAnimationFrame:e=>(0,U.PG)((0,U.zk)(this._element),e),smoothScrollDuration:100})),this._scrollableElement=this._register(new hi.oO(this._scrollableElements.root,{vertical:1,horizontal:1,useShadows:!1},this._scrollable)),this._elements=(0,U.h)("div.monaco-component.multiDiffEditor",{},[(0,U.h)("div",{},[this._scrollableElement.getDomNode()]),(0,U.h)("div.placeholder@placeholder",{},[(0,U.h)("div",[(0,b.kg)("noChangedFiles","No Changed Files")])])]),this._sizeObserver=this._register(new Bo.pN(this._element,void 0)),this._objectPool=this._register(new Xo((e=>{const t=this._instantiationService.createInstance(Qo,this._scrollableElements.content,this._scrollableElements.overflowWidgetsDomNode,this._workbenchUIElementFactory);return t.setData(e),t}))),this.scrollTop=(0,Bs.y0)(this,this._scrollableElement.onScroll,(()=>this._scrollableElement.getScrollPosition().scrollTop)),this.scrollLeft=(0,Bs.y0)(this,this._scrollableElement.onScroll,(()=>this._scrollableElement.getScrollPosition().scrollLeft)),this._viewItemsInfo=(0,Bs.rm)(this,((e,t)=>{const i=this._viewModel.read(e);if(!i)return{items:[],getItem:e=>{throw new v.D7}};const s=i.items.read(e),n=new Map;return{items:s.map((e=>{const i=t.add(new ta(e,this._objectPool,this.scrollLeft,(e=>{this._scrollableElement.setScrollPosition({scrollTop:this._scrollableElement.getScrollPosition().scrollTop+e})}))),s=this._lastDocStates?.[i.getKey()];return s&&(0,Uo.Rn)((e=>{i.setViewState(s,e)})),n.set(e,i),i})),getItem:e=>n.get(e)}})),this._viewItems=this._viewItemsInfo.map(this,(e=>e.items)),this._spaceBetweenPx=0,this._totalHeight=this._viewItems.map(this,((e,t)=>e.reduce(((e,i)=>e+i.contentHeight.read(t)+this._spaceBetweenPx),0))),this._contextKeyService=this._register(this._parentContextKeyService.createScoped(this._element)),this._instantiationService=this._register(this._parentInstantiationService.createChild(new ir.a([ie.fN,this._contextKeyService]))),this._lastDocStates={},this._contextKeyService.createKey(zo.R.inMultiDiffEditor.key,!0),this._register((0,Bs.yC)(((e,t)=>{const i=this._viewModel.read(e);if(i&&i.contextKeys)for(const[s,n]of Object.entries(i.contextKeys)){const e=this._contextKeyService.createKey(s,void 0);e.set(n),t.add((0,c.s)((()=>e.reset())))}})));const o=this._parentContextKeyService.createKey(zo.R.multiDiffEditorAllCollapsed.key,!1);this._register((0,Bs.fm)((e=>{const t=this._viewModel.read(e);if(t){const i=t.items.read(e).every((t=>t.collapsed.read(e)));o.set(i)}}))),this._register((0,Bs.fm)((e=>{const t=this._dimension.read(e);this._sizeObserver.observe(t)}))),this._register((0,Bs.fm)((e=>{const t=this._viewItems.read(e);this._elements.placeholder.classList.toggle("visible",0===t.length)}))),this._scrollableElements.content.style.position="relative",this._register((0,Bs.fm)((e=>{const t=this._sizeObserver.height.read(e);this._scrollableElements.root.style.height=`${t}px`;const i=this._totalHeight.read(e);this._scrollableElements.content.style.height=`${i}px`;const s=this._sizeObserver.width.read(e);let n=s;const r=this._viewItems.read(e),o=(0,Fo.Cn)(r,(0,E.VE)((t=>t.maxScroll.read(e).maxScroll),E.U9));if(o){n=s+o.maxScroll.read(e).maxScroll}this._scrollableElement.setScrollDimensions({width:s,height:t,scrollHeight:i,scrollWidth:n})}))),e.replaceChildren(this._elements.root),this._register((0,c.s)((()=>{e.replaceChildren()}))),this._register(this._register((0,Bs.fm)((e=>{(0,Uo.YY)((t=>{this.render(e)}))}))))}render(e){const t=this.scrollTop.read(e);let i=0,s=0,n=0;const r=this._sizeObserver.height.read(e),o=Wo.L.ofStartAndLength(t,r),a=this._sizeObserver.width.read(e);for(const c of this._viewItems.read(e)){const l=c.contentHeight.read(e),h=Math.min(l,r),d=Wo.L.ofStartAndLength(s,h),u=Wo.L.ofStartAndLength(n,l);if(u.isBefore(o))i-=l-h,c.hide();else if(u.isAfter(o))c.hide();else{const e=Math.max(0,Math.min(o.start-u.start,l-h));i-=e;const s=Wo.L.ofStartAndLength(t+i,r);c.render(d,e,a,s)}s+=h+this._spaceBetweenPx,n+=l+this._spaceBetweenPx}this._scrollableElements.content.style.transform=`translateY(${-(t+i)}px)`}};ea=Zo([Jo(4,ie.fN),Jo(5,ae._Y)],ea);class ta extends c.jG{constructor(e,t,i,s){super(),this.viewModel=e,this._objectPool=t,this._scrollLeft=i,this._deltaScrollVertical=s,this._templateRef=this._register((0,Uo.X2)(this,void 0)),this.contentHeight=(0,Bs.un)(this,(e=>this._templateRef.read(e)?.object.contentHeight?.read(e)??this.viewModel.lastTemplateData.read(e).contentHeight)),this.maxScroll=(0,Bs.un)(this,(e=>this._templateRef.read(e)?.object.maxScroll.read(e)??{maxScroll:0,scrollWidth:0})),this.template=(0,Bs.un)(this,(e=>this._templateRef.read(e)?.object)),this._isHidden=(0,Bs.FY)(this,!1),this._isFocused=(0,Bs.un)(this,(e=>this.template.read(e)?.isFocused.read(e)??!1)),this.viewModel.setIsFocused(this._isFocused,void 0),this._register((0,Bs.fm)((e=>{const t=this._scrollLeft.read(e);this._templateRef.read(e)?.object.setScrollLeft(t)}))),this._register((0,Bs.fm)((e=>{const t=this._templateRef.read(e);if(!t)return;if(!this._isHidden.read(e))return;t.object.isFocused.read(e)||this._clear()})))}dispose(){this._clear(),super.dispose()}toString(){return`VirtualViewItem(${this.viewModel.documentDiffItem.modified?.uri.toString()})`}getKey(){return this.viewModel.getKey()}setViewState(e,t){this.viewModel.collapsed.set(e.collapsed,t),this._updateTemplateData(t);const i=this.viewModel.lastTemplateData.get(),s=e.selections?.map(Vo.L.liftSelection);this.viewModel.lastTemplateData.set({...i,selections:s},t);const n=this._templateRef.get();n&&s&&n.object.editor.setSelections(s)}_updateTemplateData(e){const t=this._templateRef.get();t&&this.viewModel.lastTemplateData.set({contentHeight:t.object.contentHeight.get(),selections:t.object.editor.getSelections()??void 0},e)}_clear(){const e=this._templateRef.get();e&&(0,Uo.Rn)((t=>{this._updateTemplateData(t),e.object.hide(),this._templateRef.set(void 0,t)}))}hide(){this._isHidden.set(!0,void 0)}render(e,t,i,s){this._isHidden.set(!1,void 0);let n=this._templateRef.get();if(!n){n=this._objectPool.getUnusedObj(new $o(this.viewModel,this._deltaScrollVertical)),this._templateRef.set(n,void 0);const e=this.viewModel.lastTemplateData.get().selections;e&&n.object.editor.setSelections(e)}n.object.render(e,i,t,s)}}(0,Ne.x1A)("multiDiffEditor.headerBackground",{dark:"#262626",light:"tab.inactiveBackground",hcDark:"tab.inactiveBackground",hcLight:"tab.inactiveBackground"},(0,b.kg)("multiDiffEditor.headerBackground","The background color of the diff editor's header")),(0,Ne.x1A)("multiDiffEditor.background",Ne.YtV,(0,b.kg)("multiDiffEditor.background","The background color of the multi file diff editor")),(0,Ne.x1A)("multiDiffEditor.border",{dark:"sideBarSectionHeader.border",light:"#cccccc",hcDark:"sideBarSectionHeader.border",hcLight:"#cccccc"},(0,b.kg)("multiDiffEditor.border","The border color of the multi file diff editor"));var ia=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},sa=function(e,t){return function(i,s){t(i,s,e)}};let na=class extends c.jG{constructor(e,t,i){super(),this._element=e,this._workbenchUIElementFactory=t,this._instantiationService=i,this._dimension=(0,Bs.FY)(this,void 0),this._viewModel=(0,Bs.FY)(this,void 0),this._widgetImpl=(0,Bs.rm)(this,((e,t)=>((0,Po.b)(Qo,e),t.add(this._instantiationService.createInstance((0,Po.b)(ea,e),this._element,this._dimension,this._viewModel,this._workbenchUIElementFactory))))),this._register((0,Bs.OI)(this._widgetImpl))}};function ra(e,t,i){return Hr.initialize(i||{}).createInstance(Io,e,t)}function oa(e){return Hr.get(g.T).onCodeEditorAdd((t=>{e(t)}))}function aa(e){return Hr.get(g.T).onDiffEditorAdd((t=>{e(t)}))}function ca(){return Hr.get(g.T).listCodeEditors()}function la(){return Hr.get(g.T).listDiffEditors()}function ha(e,t,i){return Hr.initialize(i||{}).createInstance(Oo,e,t)}function da(e,t){const i=Hr.initialize(t||{});return new na(e,{},i)}function ua(e){if("string"!==typeof e.id||"function"!==typeof e.run)throw new Error("Invalid command descriptor, `id` and `run` are required properties!");return St.w.registerCommand(e.id,e.run)}function ga(e){if("string"!==typeof e.id||"string"!==typeof e.label||"function"!==typeof e.run)throw new Error("Invalid action descriptor, `id`, `label` and `run` are required properties!");const t=ie.M$.deserialize(e.precondition),i=new c.Cm;if(i.add(St.w.registerCommand(e.id,((i,...s)=>u.DX.runEditorCommand(i,s,t,((t,i,s)=>Promise.resolve(e.run(i,...s))))))),e.contextMenuGroupId){const s={command:{id:e.id,title:e.label},when:t,group:e.contextMenuGroupId,order:e.contextMenuOrder||0};i.add(ni.ZG.appendMenuItem(ni.D8.EditorContext,s))}if(Array.isArray(e.keybindings)){const s=Hr.get(De.b);if(s instanceof Rr){const n=ie.M$.and(t,ie.M$.deserialize(e.keybindingContext));i.add(s.addDynamicKeybindings(e.keybindings.map((t=>({keybinding:t,command:e.id,when:n})))))}else console.warn("Cannot add keybinding because the editor is configured with an unrecognized KeybindingService")}return i}function pa(e){return ma([e])}function ma(e){const t=Hr.get(De.b);return t instanceof Rr?t.addDynamicKeybindings(e.map((e=>({keybinding:e.keybinding,command:e.command,commandArgs:e.commandArgs,when:ie.M$.deserialize(e.when)})))):(console.warn("Cannot add keybinding because the editor is configured with an unrecognized KeybindingService"),c.jG.None)}function fa(e,t,i){const s=Hr.get(Ui.L),n=s.getLanguageIdByMimeType(t)||t;return Do(Hr.get(A.IModelService),s,e,n,i)}function _a(e,t){const i=Hr.get(Ui.L),s=i.getLanguageIdByMimeType(t)||t||jr.vH;e.setLanguage(i.createById(s))}function va(e,t,i){if(e){Hr.get(or.DR).changeOne(t,e.uri,i)}}function Ca(e){Hr.get(or.DR).changeAll(e,[])}function Ea(e){return Hr.get(or.DR).read(e)}function ba(e){return Hr.get(or.DR).onMarkerChanged(e)}function Sa(e){return Hr.get(A.IModelService).getModel(e)}function ya(){return Hr.get(A.IModelService).getModels()}function wa(e){return Hr.get(A.IModelService).onModelAdded(e)}function Ra(e){return Hr.get(A.IModelService).onModelRemoved(e)}function La(e){return Hr.get(A.IModelService).onModelLanguageChanged((t=>{e({model:t.model,oldLanguage:t.oldLanguageId})}))}function Ta(e){return function(e,t){return new Br(e,t)}(Hr.get(A.IModelService),e)}function xa(e,t){const i=Hr.get(Ui.L),s=Hr.get(Ln.L);return bo.colorizeElement(s,i,e,t).then((()=>{s.registerEditorContainer(e)}))}function ka(e,t,i){const s=Hr.get(Ui.L);return Hr.get(Ln.L).registerEditorContainer(a.G.document.body),bo.colorize(s,e,t,i)}function Aa(e,t,i=4){return Hr.get(Ln.L).registerEditorContainer(a.G.document.body),bo.colorizeModelLine(e,t,i)}function Na(e,t){Gr.dG.getOrCreate(t);const i=function(e){const t=Gr.dG.get(e);return t||{getInitialState:()=>Kr.r3,tokenize:(t,i,s)=>(0,Kr.$H)(e,s)}}(t),s=(0,l.uz)(e),n=[];let r=i.getInitialState();for(let o=0,a=s.length;o("string"===typeof t&&(t=h.r.parse(t)),e.open(t))})}function Fa(e){return Hr.get(g.T).registerCodeEditorOpenHandler((async(t,i,s)=>{if(!i)return null;const n=t.options?.selection;let r;return n&&"number"===typeof n.endLineNumber&&"number"===typeof n.endColumn?r=n:n&&(r={lineNumber:n.startLineNumber,column:n.startColumn}),await e.openCodeEditor(i,t.resource,r)?i:null}))}na=ia([sa(2,ae._Y)],na);var Ua=i(47661);function Ha(e,t){return"boolean"===typeof e?e:t}function Ba(e,t){return"string"===typeof e?e:t}function Wa(e,t=!1){t&&(e=e.map((function(e){return e.toLowerCase()})));const i=function(e){const t={};for(const i of e)t[i]=!0;return t}(e);return t?function(e){return void 0!==i[e.toLowerCase()]&&i.hasOwnProperty(e.toLowerCase())}:function(e){return void 0!==i[e]&&i.hasOwnProperty(e)}}function Va(e,t,i){t=t.replace(/@@/g,"\x01");let s,n=0;do{s=!1,t=t.replace(/@(\w+)/g,(function(i,n){s=!0;let r="";if("string"===typeof e[n])r=e[n];else{if(!(e[n]&&e[n]instanceof RegExp))throw void 0===e[n]?no(e,"language definition does not contain attribute '"+n+"', used at: "+t):no(e,"attribute reference '"+n+"' must be a string, used at: "+t);r=e[n].source}return to(r)?"":"(?:"+r+")"})),n++}while(s&&n<5);t=t.replace(/\x01/g,"@");const r=(e.ignoreCase?"i":"")+(e.unicode?"u":"");if(i){if(t.match(/\$[sS](\d\d?)/g)){let i=null,s=null;return n=>(s&&i===n||(i=n,s=new RegExp(function(e,t,i){let s=null;return t.replace(/\$[sS](\d\d?)/g,(function(t,n){return null===s&&(s=i.split("."),s.unshift(i)),!to(n)&&n=100){s-=100;const e=i.split(".");if(e.unshift(i),s=0&&(s.tokenSubst=!0),"string"===typeof i.bracket)if("@open"===i.bracket)s.bracket=1;else{if("@close"!==i.bracket)throw no(e,"a 'bracket' attribute must be either '@open' or '@close', in rule: "+t);s.bracket=-1}if(i.next){if("string"!==typeof i.next)throw no(e,"the next state must be a string value in rule: "+t);{let n=i.next;if(!/^(@pop|@push|@popall)$/.test(n)&&("@"===n[0]&&(n=n.substr(1)),n.indexOf("$")<0&&!function(e,t){let i=t;for(;i&&i.length>0;){if(e.stateNames[i])return!0;const t=i.lastIndexOf(".");i=t<0?null:i.substr(0,t)}return!1}(e,ro(e,n,"",[],""))))throw no(e,"the next state '"+i.next+"' is not defined in rule: "+t);s.next=n}}return"number"===typeof i.goBack&&(s.goBack=i.goBack),"string"===typeof i.switchTo&&(s.switchTo=i.switchTo),"string"===typeof i.log&&(s.log=i.log),"string"===typeof i.nextEmbedded&&(s.nextEmbedded=i.nextEmbedded,e.usesEmbedded=!0),s}}if(Array.isArray(i)){const s=[];for(let n=0,r=i.length;n0&&"^"===i[0],this.name=this.name+": "+i,this.regex=Va(e,"^(?:"+(this.matchOnlyAtLineStart?i.substr(1):i)+")",!0)}setAction(e,t){this.action=Ga(e,this.name,t)}resolveRegex(e){return this.regex instanceof RegExp?this.regex:this.regex(e)}}function Ka(e,t){if(!t||"object"!==typeof t)throw new Error("Monarch: expecting a language definition object");const i={languageId:e,includeLF:Ha(t.includeLF,!1),noThrow:!1,maxStack:100,start:"string"===typeof t.start?t.start:null,ignoreCase:Ha(t.ignoreCase,!1),unicode:Ha(t.unicode,!1),tokenPostfix:Ba(t.tokenPostfix,"."+e),defaultToken:Ba(t.defaultToken,"source"),usesEmbedded:!1,stateNames:{},tokenizer:{},brackets:[]},s=t;function n(e,r,o){for(const a of o){let o=a.include;if(o){if("string"!==typeof o)throw no(i,"an 'include' attribute must be a string at: "+e);if("@"===o[0]&&(o=o.substr(1)),!t.tokenizer[o])throw no(i,"include target '"+o+"' is not defined at: "+e);n(e+"."+o,r,t.tokenizer[o])}else{const t=new ja(e);if(Array.isArray(a)&&a.length>=1&&a.length<=3)if(t.setRegex(s,a[0]),a.length>=3)if("string"===typeof a[1])t.setAction(s,{token:a[1],next:a[2]});else{if("object"!==typeof a[1])throw no(i,"a next state as the last element of a rule can only be given if the action is either an object or a string, at: "+e);{const e=a[1];e.next=a[2],t.setAction(s,e)}}else t.setAction(s,a[1]);else{if(!a.regex)throw no(i,"a rule must either be an array, or an object with a 'regex' or 'include' field at: "+e);a.name&&"string"===typeof a.name&&(t.name=a.name),a.matchOnlyAtStart&&(t.matchOnlyAtLineStart=Ha(a.matchOnlyAtLineStart,!1)),t.setRegex(s,a.regex),t.setAction(s,a.action)}r.push(t)}}}if(s.languageId=e,s.includeLF=i.includeLF,s.ignoreCase=i.ignoreCase,s.unicode=i.unicode,s.noThrow=i.noThrow,s.usesEmbedded=i.usesEmbedded,s.stateNames=t.tokenizer,s.defaultToken=i.defaultToken,!t.tokenizer||"object"!==typeof t.tokenizer)throw no(i,"a language definition must define the 'tokenizer' attribute as an object");i.tokenizer=[];for(const o in t.tokenizer)if(t.tokenizer.hasOwnProperty(o)){i.start||(i.start=o);const e=t.tokenizer[o];i.tokenizer[o]=new Array,n("tokenizer."+o,i.tokenizer[o],e)}if(i.usesEmbedded=s.usesEmbedded,t.brackets){if(!Array.isArray(t.brackets))throw no(i,"the 'brackets' attribute must be defined as an array")}else t.brackets=[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}];const r=[];for(const o of t.brackets){let e=o;if(e&&Array.isArray(e)&&3===e.length&&(e={token:e[2],open:e[0],close:e[1]}),e.open===e.close)throw no(i,"open and close brackets in a 'brackets' attribute must be different: "+e.open+"\n hint: use the 'bracket' attribute if matching on equal brackets is required.");if("string"!==typeof e.open||"string"!==typeof e.token||"string"!==typeof e.close)throw no(i,"every element in the 'brackets' array must be a '{open,close,token}' object or array");r.push({token:e.token+i.tokenPostfix,open:io(i,e.open),close:io(i,e.close)})}return i.brackets=r,i.noThrow=!0,i}function Ya(e){jr.W6.registerLanguage(e)}function qa(){let e=[];return e=e.concat(jr.W6.getLanguages()),e}function $a(e){return Hr.get(Ui.L).languageIdCodec.encodeLanguageId(e)}function Qa(e,t){return Hr.withServices((()=>{const i=Hr.get(Ui.L).onDidRequestRichLanguageFeatures((s=>{s===e&&(i.dispose(),t())}));return i}))}function Xa(e,t){return Hr.withServices((()=>{const i=Hr.get(Ui.L).onDidRequestBasicLanguageFeatures((s=>{s===e&&(i.dispose(),t())}));return i}))}function Za(e,t){if(!Hr.get(Ui.L).isRegisteredLanguageId(e))throw new Error(`Cannot set configuration for unknown language ${e}`);return Hr.get(x.JZ).register(e,t,100)}class Ja{constructor(e,t){this._languageId=e,this._actual=t}dispose(){}getInitialState(){return this._actual.getInitialState()}tokenize(e,t,i){if("function"===typeof this._actual.tokenize)return ec.adaptTokenize(this._languageId,this._actual,e,i);throw new Error("Not supported!")}tokenizeEncoded(e,t,i){const s=this._actual.tokenizeEncoded(e,i);return new Gr.rY(s.tokens,s.endState)}}class ec{constructor(e,t,i,s){this._languageId=e,this._actual=t,this._languageService=i,this._standaloneThemeService=s}dispose(){}getInitialState(){return this._actual.getInitialState()}static _toClassicTokens(e,t){const i=[];let s=0;for(let n=0,r=e.length;n0&&n[r-1]===a)continue;let l=e.startIndex;0===c?l=0:l{const i=await Promise.resolve(t.create());return i?"function"===typeof i.getInitialState?sc(e,i):new vo(Hr.get(Ui.L),Hr.get(Ln.L),e,Ka(e,i),Hr.get(Me.pG)):null}));return Gr.dG.registerFactory(e,i)}function rc(e,t){if(!Hr.get(Ui.L).isRegisteredLanguageId(e))throw new Error(`Cannot set tokens provider for unknown language ${e}`);return tc(t)?nc(e,{create:()=>t}):Gr.dG.register(e,sc(e,t))}function oc(e,t){return tc(t)?nc(e,{create:()=>t}):Gr.dG.register(e,(t=>new vo(Hr.get(Ui.L),Hr.get(Ln.L),e,Ka(e,t),Hr.get(Me.pG)))(t))}function ac(e,t){return Hr.get(D.ILanguageFeaturesService).referenceProvider.register(e,t)}function cc(e,t){return Hr.get(D.ILanguageFeaturesService).renameProvider.register(e,t)}function lc(e,t){return Hr.get(D.ILanguageFeaturesService).newSymbolNamesProvider.register(e,t)}function hc(e,t){return Hr.get(D.ILanguageFeaturesService).signatureHelpProvider.register(e,t)}function dc(e,t){return Hr.get(D.ILanguageFeaturesService).hoverProvider.register(e,{provideHover:async(e,i,s,n)=>{const r=e.getWordAtPosition(i);return Promise.resolve(t.provideHover(e,i,s,n)).then((e=>{if(e)return!e.range&&r&&(e.range=new T.Q(i.lineNumber,r.startColumn,i.lineNumber,r.endColumn)),e.range||(e.range=new T.Q(i.lineNumber,i.column,i.lineNumber,i.column)),e}))}})}function uc(e,t){return Hr.get(D.ILanguageFeaturesService).documentSymbolProvider.register(e,t)}function gc(e,t){return Hr.get(D.ILanguageFeaturesService).documentHighlightProvider.register(e,t)}function pc(e,t){return Hr.get(D.ILanguageFeaturesService).linkedEditingRangeProvider.register(e,t)}function mc(e,t){return Hr.get(D.ILanguageFeaturesService).definitionProvider.register(e,t)}function fc(e,t){return Hr.get(D.ILanguageFeaturesService).implementationProvider.register(e,t)}function _c(e,t){return Hr.get(D.ILanguageFeaturesService).typeDefinitionProvider.register(e,t)}function vc(e,t){return Hr.get(D.ILanguageFeaturesService).codeLensProvider.register(e,t)}function Cc(e,t,i){return Hr.get(D.ILanguageFeaturesService).codeActionProvider.register(e,{providedCodeActionKinds:i?.providedCodeActionKinds,documentation:i?.documentation,provideCodeActions:(e,i,s,n)=>{const r=Hr.get(or.DR).read({resource:e.uri}).filter((e=>T.Q.areIntersectingOrTouching(e,i)));return t.provideCodeActions(e,i,{markers:r,only:s.only,trigger:s.trigger},n)},resolveCodeAction:t.resolveCodeAction})}function Ec(e,t){return Hr.get(D.ILanguageFeaturesService).documentFormattingEditProvider.register(e,t)}function bc(e,t){return Hr.get(D.ILanguageFeaturesService).documentRangeFormattingEditProvider.register(e,t)}function Sc(e,t){return Hr.get(D.ILanguageFeaturesService).onTypeFormattingEditProvider.register(e,t)}function yc(e,t){return Hr.get(D.ILanguageFeaturesService).linkProvider.register(e,t)}function wc(e,t){return Hr.get(D.ILanguageFeaturesService).completionProvider.register(e,t)}function Rc(e,t){return Hr.get(D.ILanguageFeaturesService).colorProvider.register(e,t)}function Lc(e,t){return Hr.get(D.ILanguageFeaturesService).foldingRangeProvider.register(e,t)}function Tc(e,t){return Hr.get(D.ILanguageFeaturesService).declarationProvider.register(e,t)}function xc(e,t){return Hr.get(D.ILanguageFeaturesService).selectionRangeProvider.register(e,t)}function kc(e,t){return Hr.get(D.ILanguageFeaturesService).documentSemanticTokensProvider.register(e,t)}function Ac(e,t){return Hr.get(D.ILanguageFeaturesService).documentRangeSemanticTokensProvider.register(e,t)}function Nc(e,t){return Hr.get(D.ILanguageFeaturesService).inlineCompletionsProvider.register(e,t)}function Ic(e,t){return Hr.get(D.ILanguageFeaturesService).inlineEditProvider.register(e,t)}function Oc(e,t){return Hr.get(D.ILanguageFeaturesService).inlayHintsProvider.register(e,t)}var Dc=i(49079);r.qB.wrappingIndent.defaultValue=0,r.qB.glyphMargin.defaultValue=!1,r.qB.autoIndent.defaultValue=3,r.qB.overviewRulerLanes.defaultValue=2,Dc.Pj.setFormatterSelector(((e,t,i)=>Promise.resolve(e[0])));const Mc=(0,o.createMonacoBaseAPI)();Mc.editor={create:ra,getEditors:ca,getDiffEditors:la,onDidCreateEditor:oa,onDidCreateDiffEditor:aa,createDiffEditor:ha,addCommand:ua,addEditorAction:ga,addKeybindingRule:pa,addKeybindingRules:ma,createModel:fa,setModelLanguage:_a,setModelMarkers:va,getModelMarkers:Ea,removeAllMarkers:Ca,onDidChangeMarkers:ba,getModels:ya,getModel:Sa,onDidCreateModel:wa,onWillDisposeModel:Ra,onDidChangeModelLanguage:La,createWebWorker:Ta,colorizeElement:xa,colorize:ka,colorizeModelLine:Aa,tokenize:Na,defineTheme:Ia,setTheme:Oa,remeasureFonts:Da,registerCommand:Ma,registerLinkOpener:Pa,registerEditorOpener:Fa,AccessibilitySupport:qr.Gn,ContentWidgetPositionPreference:qr.Qj,CursorChangeReason:qr.h5,DefaultEndOfLine:qr.of,EditorAutoIndentStrategy:qr.e0,EditorOption:qr.p2,EndOfLinePreference:qr.kf,EndOfLineSequence:qr.WU,MinimapPosition:qr.R3,MinimapSectionHeaderStyle:qr.VX,MouseTargetType:qr.hS,OverlayWidgetPositionPreference:qr.dE,OverviewRulerLane:qr.A5,GlyphMarginLane:qr.ZS,RenderLineNumbersType:qr.DO,RenderMinimap:qr.hW,ScrollbarVisibility:qr.XR,ScrollType:qr.ov,TextEditorCursorBlinkingStyle:qr.U7,TextEditorCursorStyle:qr.m9,TrackedRangeStickiness:qr.kK,WrappingIndent:qr.tJ,InjectedTextCursorStops:qr.VW,PositionAffinity:qr.Ic,ShowLightbulbIconMode:qr.jT,ConfigurationChangedEvent:r.lw,BareFontInfo:Vr._8,FontInfo:Vr.YJ,TextModelResolvedOptions:Yr.X2,FindMatch:Yr.Dg,ApplyUpdateResult:r.hZ,EditorZoom:Wr.D,createMultiFileDiffEditor:da,EditorType:zr._,EditorOptions:r.qB},Mc.languages={register:Ya,getLanguages:qa,onLanguage:Qa,onLanguageEncountered:Xa,getEncodedLanguageId:$a,setLanguageConfiguration:Za,setColorMap:ic,registerTokensProviderFactory:nc,setTokensProvider:rc,setMonarchTokensProvider:oc,registerReferenceProvider:ac,registerRenameProvider:cc,registerNewSymbolNameProvider:lc,registerCompletionItemProvider:wc,registerSignatureHelpProvider:hc,registerHoverProvider:dc,registerDocumentSymbolProvider:uc,registerDocumentHighlightProvider:gc,registerLinkedEditingRangeProvider:pc,registerDefinitionProvider:mc,registerImplementationProvider:fc,registerTypeDefinitionProvider:_c,registerCodeLensProvider:vc,registerCodeActionProvider:Cc,registerDocumentFormattingEditProvider:Ec,registerDocumentRangeFormattingEditProvider:bc,registerOnTypeFormattingEditProvider:Sc,registerLinkProvider:yc,registerColorProvider:Rc,registerFoldingRangeProvider:Lc,registerDeclarationProvider:Tc,registerSelectionRangeProvider:xc,registerDocumentSemanticTokensProvider:kc,registerDocumentRangeSemanticTokensProvider:Ac,registerInlineCompletionsProvider:Nc,registerInlineEditProvider:Ic,registerInlayHintsProvider:Oc,DocumentHighlightKind:qr.Kb,CompletionItemKind:qr.Io,CompletionItemTag:qr.QP,CompletionItemInsertTextRule:qr._E,SymbolKind:qr.v0,SymbolTag:qr.H_,IndentAction:qr.l,CompletionTriggerKind:qr.t7,SignatureHelpTriggerKind:qr.WA,InlayHintKind:qr.r4,InlineCompletionTriggerKind:qr.qw,InlineEditTriggerKind:qr.sm,CodeActionTriggerType:qr.ok,NewSymbolNameTag:qr.OV,NewSymbolNameTriggerKind:qr.YT,PartialAcceptTriggerKind:qr.Ah,HoverVerbosityAction:qr.M$,FoldingRangeKind:Gr.lO,SelectedSuggestionInfo:Gr.GE};const Pc=Mc.CancellationTokenSource,Fc=Mc.Emitter,Uc=Mc.KeyCode,Hc=Mc.KeyMod,Bc=Mc.Position,Wc=Mc.Range,Vc=Mc.Selection,zc=Mc.SelectionDirection,Gc=Mc.MarkerSeverity,jc=Mc.MarkerTag,Kc=Mc.Uri,Yc=Mc.Token,qc=Mc.editor,$c=Mc.languages,Qc=globalThis.MonacoEnvironment;(Qc?.globalAPI||"function"===typeof define&&i.amdO)&&(globalThis.monaco=Mc),"undefined"!==typeof globalThis.require&&"function"===typeof globalThis.require.config&&globalThis.require.config({ignoreDuplicateModules:["vscode-languageserver-types","vscode-languageserver-types/main","vscode-languageserver-textdocument","vscode-languageserver-textdocument/main","vscode-nls","vscode-nls/vscode-nls","jsonc-parser","jsonc-parser/main","vscode-uri","vscode-uri/index","vs/basic-languages/typescript/typescript"]});var Xc;i(61562),i(94318),i(23304),i(59896),i(75208),i(51232),i(77888),i(46686),i(27020),i(15600),i(80200),i(87152),i(11272),i(60352),i(66235),i(31474),i(84840),i(94803),i(74304),i(74800),i(37954),i(25922),i(46648),i(61082),i(19856),i(97884),i(89518),i(83488),i(3254),i(57680),i(99669),i(796),i(89336),i(19436),i(40340),i(52894),i(86492),i(73374),i(38320),i(92080),i(57664),i(8868),i(31396),i(18544),i(538),i(25064),i(64256),i(32624),i(97360),i(42776),i(97144),i(46304),i(58820),i(82560),i(74276),i(39866),i(73020),i(71316),i(70492),i(50848),i(59520),i(46576),i(49150),i(33358),i(96716),i(28304),i(14720),i(27734),i(2068),i(71468),i(15482),i(42572),i(77668),i(36e3),i(10072),i(48448),i(51376),i(61764),i(85872),i(24152),i(42144),i(22362),i(98408),i(61472),i(50576),i(23934);self.MonacoEnvironment=(Xc={editorWorkerService:"editor.worker.js",css:"css.worker.js",html:"html.worker.js",json:"json.worker.js",typescript:"ts.worker.js",javascript:"ts.worker.js",less:"css.worker.js",scss:"css.worker.js",handlebars:"html.worker.js",razor:"html.worker.js"},{globalAPI:!1,getWorkerUrl:function(e,t){var s=i.p,n=(s?s.replace(/\/$/,"")+"/":"")+Xc[t];if(/^((http:)|(https:)|(file:)|(\/\/))/.test(n)){var r=String(window.location),o=r.substr(0,r.length-window.location.hash.length-window.location.search.length-window.location.pathname.length);if(n.substring(0,o.length)!==o){/^(\/\/)/.test(n)&&(n=window.location.protocol+n);var a=new Blob(["/*"+t+'*/importScripts("'+n+'");'],{type:"application/javascript"});return URL.createObjectURL(a)}}return n}});const Zc=s},80789:(e,t,i)=>{"use strict";i.d(t,{H:()=>n});var s=i(64383);function n(e,t){const i=globalThis.MonacoEnvironment;if(i?.createTrustedTypesPolicy)try{return i.createTrustedTypesPolicy(e,t)}catch(n){return void(0,s.dz)(n)}try{return globalThis.trustedTypes?.createPolicy(e,t)}catch(n){return void(0,s.dz)(n)}}},80953:(e,t,i)=>{"use strict";i.d(t,{t:()=>r});var s=i(59284);const n=(0,i(69220).om)("spin"),r=s.forwardRef((function(e,t){const{size:i="m",style:r,className:o,qa:a}=e;return s.createElement("div",{ref:t,style:r,className:n({size:i},o),"data-qa":a},s.createElement("div",{className:n("inner")}))}))},81091:(e,t,i)=>{"use strict";var s=i(5662),n=i(34326),r=i(12437),o=i(78209);class a extends r.o{static{this.PREFIX=":"}constructor(){super({canAcceptInBackground:!0})}provideWithoutTextEditor(e){const t=(0,o.kg)("cannotRunGotoLine","Open a text editor first to go to a line.");return e.items=[{label:t}],e.ariaLabel=t,s.jG.None}provideWithTextEditor(e,t,i){const r=e.editor,o=new s.Cm;o.add(t.onDidAccept((i=>{const[s]=t.selectedItems;if(s){if(!this.isValidLineNumber(r,s.lineNumber))return;this.gotoLocation(e,{range:this.toRange(s.lineNumber,s.column),keyMods:t.keyMods,preserveFocus:i.inBackground}),i.inBackground||t.hide()}})));const c=()=>{const e=this.parsePosition(r,t.value.trim().substr(a.PREFIX.length)),i=this.getPickLabel(r,e.lineNumber,e.column);if(t.items=[{lineNumber:e.lineNumber,column:e.column,label:i}],t.ariaLabel=i,!this.isValidLineNumber(r,e.lineNumber))return void this.clearDecorations(r);const s=this.toRange(e.lineNumber,e.column);r.revealRangeInCenter(s,0),this.addDecorations(r,s)};c(),o.add(t.onDidChangeValue((()=>c())));const l=(0,n.jA)(r);if(l){2===l.getOptions().get(68).renderType&&(l.updateOptions({lineNumbers:"on"}),o.add((0,s.s)((()=>l.updateOptions({lineNumbers:"relative"})))))}return o}toRange(e=1,t=1){return{startLineNumber:e,startColumn:t,endLineNumber:e,endColumn:t}}parsePosition(e,t){const i=t.split(/,|:|#/).map((e=>parseInt(e,10))).filter((e=>!isNaN(e))),s=this.lineCount(e)+1;return{lineNumber:i[0]>0?i[0]:s+i[0],column:i[1]}}getPickLabel(e,t,i){if(this.isValidLineNumber(e,t))return this.isValidColumn(e,t,i)?(0,o.kg)("gotoLineColumnLabel","Go to line {0} and character {1}.",t,i):(0,o.kg)("gotoLineLabel","Go to line {0}.",t);const s=e.getPosition()||{lineNumber:1,column:1},n=this.lineCount(e);return n>1?(0,o.kg)("gotoLineLabelEmptyWithLimit","Current Line: {0}, Character: {1}. Type a line number between 1 and {2} to navigate to.",s.lineNumber,s.column,n):(0,o.kg)("gotoLineLabelEmpty","Current Line: {0}, Character: {1}. Type a line number to navigate to.",s.lineNumber,s.column)}isValidLineNumber(e,t){return!(!t||"number"!==typeof t)&&(t>0&&t<=this.lineCount(e))}isValidColumn(e,t,i){if(!i||"number"!==typeof i)return!1;const s=this.getModel(e);if(!s)return!1;const n={lineNumber:t,column:i};return s.validatePosition(n).equals(n)}lineCount(e){return this.getModel(e)?.getLineCount()??0}}var c=i(46359),l=i(71597),h=i(80301),d=i(51861),u=i(41234),g=i(31450),p=i(60002),m=i(51467),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class extends a{constructor(e){super(),this.editorService=e,this.onDidActiveTextEditorControlChange=u.Jh.None}get activeTextEditorControl(){return this.editorService.getFocusedCodeEditor()??void 0}};v=f([_(0,h.T)],v);class C extends g.ks{static{this.ID="editor.action.gotoLine"}constructor(){super({id:C.ID,label:d.Hw.gotoLineActionLabel,alias:"Go to Line/Column...",precondition:void 0,kbOpts:{kbExpr:p.R.focus,primary:2085,mac:{primary:293},weight:100}})}run(e){e.get(m.GK).quickAccess.show(v.PREFIX)}}(0,g.Fl)(C),c.O.as(l.Fd.Quickaccess).registerQuickAccessProvider({ctor:v,prefix:v.PREFIX,helpEntries:[{description:d.Hw.gotoLineActionLabel,commandId:C.ID}]})},81674:(e,t,i)=>{"use strict";i.d(t,{$l:()=>a,Gs:()=>u,MB:()=>o,Sw:()=>h,bb:()=>l,gN:()=>c,pJ:()=>d});var s=i(91090);const n="undefined"!==typeof Buffer;new s.d((()=>new Uint8Array(256)));let r;class o{static wrap(e){return n&&!Buffer.isBuffer(e)&&(e=Buffer.from(e.buffer,e.byteOffset,e.byteLength)),new o(e)}constructor(e){this.buffer=e,this.byteLength=this.buffer.byteLength}toString(){return n?this.buffer.toString():(r||(r=new TextDecoder),r.decode(this.buffer))}}function a(e,t){return(e[t+0]|0)>>>0|e[t+1]<<8>>>0}function c(e,t,i){e[i+0]=255&t,t>>>=8,e[i+1]=255&t}function l(e,t){return e[t]*2**24+65536*e[t+1]+256*e[t+2]+e[t+3]}function h(e,t,i){e[i+3]=t,t>>>=8,e[i+2]=t,t>>>=8,e[i+1]=t,t>>>=8,e[i]=t}function d(e,t){return e[t]}function u(e,t,i){e[i]=t}},81782:(e,t,i)=>{"use strict";i.d(t,{i:()=>a});var s=i(74320),n=i(60534);class r extends n.V{constructor(e,t){super(0),this._segmenter=null,this._cachedLine=null,this._cachedSegments=[],this.intlSegmenterLocales=t,this.intlSegmenterLocales.length>0?this._segmenter=new Intl.Segmenter(this.intlSegmenterLocales,{granularity:"word"}):this._segmenter=null;for(let i=0,s=e.length;it)break;i=s}return i}findNextIntlWordAtOrAfterOffset(e,t){for(const i of this._getIntlSegmenterWordsOnLine(e))if(!(i.index{"use strict";function s(e){return e}i.d(t,{VV:()=>r,o5:()=>n});class n{constructor(e,t){this.lastCache=void 0,this.lastArgKey=void 0,"function"===typeof e?(this._fn=e,this._computeKey=s):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);return this.lastArgKey!==t&&(this.lastArgKey=t,this.lastCache=this._fn(e)),this.lastCache}}class r{get cachedValues(){return this._map}constructor(e,t){this._map=new Map,this._map2=new Map,"function"===typeof e?(this._fn=e,this._computeKey=s):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);if(this._map2.has(t))return this._map2.get(t);const i=this._fn(e);return this._map.set(e,i),this._map2.set(t,i),i}}},81824:(e,t,i)=>{var s=i(63010),n=i(78326);e.exports=function(e,t){return null!=e&&n(e,t,s)}},82320:()=>{},82365:(e,t,i)=>{"use strict";i.d(t,{$f:()=>a,MU:()=>c,Yb:()=>h,_t:()=>l,vn:()=>o});var s=i(91508),n=i(38566),r=i(27760);function o(e,t,i,o=!0,a){if(e<4)return null;const c=a.getLanguageConfiguration(t.tokenization.getLanguageId()).indentRulesSupport;if(!c)return null;const l=new r.no(t,c,a);if(i<=1)return{indentation:"",action:null};for(let s=i-1;s>0&&""===t.getLineContent(s);s--)if(1===s)return{indentation:"",action:null};const h=function(e,t,i){const s=e.tokenization.getLanguageIdAtPosition(t,0);if(t>1){let n,r=-1;for(n=t-1;n>=1;n--){if(e.tokenization.getLanguageIdAtPosition(n,0)!==s)return r;const t=e.getLineContent(n);if(!i.shouldIgnore(n)&&!/^\s+$/.test(t)&&""!==t)return n;r=n}}return-1}(t,i,l);if(h<0)return null;if(h<1)return{indentation:"",action:null};if(l.shouldIncrease(h)||l.shouldIndentNextLine(h)){const e=t.getLineContent(h);return{indentation:s.UU(e),action:n.l.Indent,line:h}}if(l.shouldDecrease(h)){const e=t.getLineContent(h);return{indentation:s.UU(e),action:null,line:h}}{if(1===h)return{indentation:s.UU(t.getLineContent(h)),action:null,line:h};const e=h-1,i=c.getIndentMetadata(t.getLineContent(e));if(!(3&i)&&4&i){let i=0;for(let t=e-1;t>0;t--)if(!l.shouldIndentNextLine(t)){i=t;break}return{indentation:s.UU(t.getLineContent(i+1)),action:null,line:i+1}}if(o)return{indentation:s.UU(t.getLineContent(h)),action:null,line:h};for(let r=h;r>0;r--){if(l.shouldIncrease(r))return{indentation:s.UU(t.getLineContent(r)),action:n.l.Indent,line:r};if(l.shouldIndentNextLine(r)){let e=0;for(let t=r-1;t>0;t--)if(!l.shouldIndentNextLine(r)){e=t;break}return{indentation:s.UU(t.getLineContent(e+1)),action:null,line:e+1}}if(l.shouldDecrease(r))return{indentation:s.UU(t.getLineContent(r)),action:null,line:r}}return{indentation:s.UU(t.getLineContent(1)),action:null,line:1}}}function a(e,t,i,a,c,l){if(e<4)return null;const h=l.getLanguageConfiguration(i);if(!h)return null;const d=l.getLanguageConfiguration(i).indentRulesSupport;if(!d)return null;const u=new r.no(t,d,l),g=o(e,t,a,void 0,l);if(g){const i=g.line;if(void 0!==i){let r=!0;for(let e=i;es===t?i:e.tokenization.getLineTokens(s),getLanguageId:()=>e.getLanguageId(),getLanguageIdAtPosition:(t,i)=>e.getLanguageIdAtPosition(t,i)},getLineContent:s=>s===t?i.getLineContent():e.getLineContent(s)};return s}(t,i.startLineNumber,g),f=(0,r.WR)(t,i.getStartPosition()),_=t.getLineContent(i.startLineNumber),v=s.UU(_),C=o(e,m,i.startLineNumber+1,void 0,c);if(!C){const e=f?v:p;return{beforeEnter:e,afterEnter:e}}let E=f?v:C.indentation;return C.action===n.l.Indent&&(E=a.shiftIndent(E)),h.shouldDecrease(u.getLineContent())&&(E=a.unshiftIndent(E)),{beforeEnter:f?v:p,afterEnter:E}}function l(e,t,i,a,c,l){const h=e.autoIndent;if(h<4)return null;if((0,r.WR)(t,i.getStartPosition()))return null;const d=t.getLanguageIdAtPosition(i.startLineNumber,i.startColumn),u=l.getLanguageConfiguration(d).indentRulesSupport;if(!u)return null;const g=new r.V(t,l).getProcessedTokenContextAroundRange(i),p=g.beforeRangeProcessedTokens.getLineContent(),m=g.afterRangeProcessedTokens.getLineContent(),f=p+m,_=p+a+m;if(!u.shouldDecrease(f)&&u.shouldDecrease(_)){const e=o(h,t,i.startLineNumber,!1,l);if(!e)return null;let s=e.indentation;return e.action!==n.l.Indent&&(s=c.unshiftIndent(s)),s}const v=i.startLineNumber-1;if(v>0){const n=t.getLineContent(v);if(u.shouldIndentNextLine(n)&&u.shouldIncrease(_)){const n=o(h,t,i.startLineNumber,!1,l),r=n?.indentation;if(void 0!==r){const n=t.getLineContent(i.startLineNumber),o=s.UU(n),l=c.shiftIndent(r)===o,h=/^\s*$/.test(f),d=e.autoClosingPairs.autoClosingPairsOpenByEnd.get(a),u=d&&d.length>0;if(l&&(u&&h))return r}}}return null}function h(e,t,i){const s=i.getLanguageConfiguration(e.getLanguageId()).indentRulesSupport;return s?t<1||t>e.getLineCount()?null:s.getIndentMetadata(e.getLineContent(t)):null}},82518:(e,t,i)=>{"use strict";i.d(t,{Lk:()=>h,NC:()=>o,Rl:()=>u,X5:()=>d,sq:()=>l});var s=i(25890),n=i(74444),r=i(68938);function o(e,t,i){let s=i;return s=a(e,t,s),s=a(e,t,s),s=function(e,t,i){if(!e.getBoundaryScore||!t.getBoundaryScore)return i;for(let s=0;s0?i[s-1]:void 0,o=i[s],a=s+10&&(c=c.delta(l))}o.push(c)}return s.length>0&&o.push(s[s.length-1]),o}function c(e,t,i,s,n){let r=1;for(;e.seq1Range.start-r>=s.start&&e.seq2Range.start-r>=n.start&&i.isStronglyEqual(e.seq2Range.start-r,e.seq2Range.endExclusive-r)&&r<100;)r++;r--;let o=0;for(;e.seq1Range.start+oc&&(c=o,a=l)}return e.delta(a)}function l(e,t,i){const s=[];for(const n of i){const e=s[s.length-1];e?n.seq1Range.start-e.seq1Range.endExclusive<=2||n.seq2Range.start-e.seq2Range.endExclusive<=2?s[s.length-1]=new r.$8(e.seq1Range.join(n.seq1Range),e.seq2Range.join(n.seq2Range)):s.push(n):s.push(n)}return s}function h(e,t,i){const s=r.$8.invert(i,e.length),n=[];let o=new r._3(0,0);function a(i,a){if(i.offset10;){const i=s[0];if(!(i.seq1Range.intersects(h.seq1Range)||i.seq2Range.intersects(h.seq2Range)))break;const n=e.findWordContaining(i.seq1Range.start),o=t.findWordContaining(i.seq2Range.start),a=new r.$8(n,o),c=a.intersect(i);if(u+=c.seq1Range.length,g+=c.seq2Range.length,h=h.join(a),!(h.seq1Range.endExclusive>=i.seq1Range.endExclusive))break;s.shift()}u+g<2*(h.seq1Range.length+h.seq2Range.length)/3&&n.push(h),o=h.getEndExclusives()}for(;s.length>0;){const e=s.shift();e.seq1Range.isEmpty||(a(e.getStarts(),e),a(e.getEndExclusives().delta(-1),e))}return function(e,t){const i=[];for(;e.length>0||t.length>0;){const s=e[0],n=t[0];let r;r=s&&(!n||s.seq1Range.start0&&i[i.length-1].seq1Range.endExclusive>=r.seq1Range.start?i[i.length-1]=i[i.length-1].join(r):i.push(r)}return i}(i,n)}function d(e,t,i){let s=i;if(0===s.length)return s;let r,o=0;do{r=!1;const a=[s[0]];for(let c=1;c5||i.seq1Range.length+i.seq2Range.length>5)}d(h,l)?(r=!0,a[a.length-1]=a[a.length-1].join(l)):a.push(l)}s=a}while(o++<10&&r);return s}function u(e,t,i){let o=i;if(0===o.length)return o;let a,c=0;do{a=!1;const h=[o[0]];for(let d=1;d5||r.length>500)return!1;const o=e.getText(r).trim();if(o.length>20||o.split(/\r\n|\r|\n/).length>1)return!1;const a=e.countLinesIn(i.seq1Range),c=i.seq1Range.length,l=t.countLinesIn(i.seq2Range),h=i.seq2Range.length,d=e.countLinesIn(s.seq1Range),p=s.seq1Range.length,m=t.countLinesIn(s.seq2Range),f=s.seq2Range.length;function _(e){return Math.min(e,130)}return Math.pow(Math.pow(_(40*a+c),1.5)+Math.pow(_(40*l+h),1.5),1.5)+Math.pow(Math.pow(_(40*d+p),1.5)+Math.pow(_(40*m+f),1.5),1.5)>74184.96480721243}p(g,u)?(a=!0,h[h.length-1]=h[h.length-1].join(u)):h.push(u)}o=h}while(c++<10&&a);const l=[];return(0,s.kj)(o,((t,i,s)=>{let o=i;function a(e){return e.length>0&&e.trim().length<=3&&i.seq1Range.length+i.seq2Range.length>100}const c=e.extendToFullLines(i.seq1Range),h=e.getText(new n.L(c.start,i.seq1Range.start));a(h)&&(o=o.deltaStart(-h.length));const d=e.getText(new n.L(i.seq1Range.endExclusive,c.endExclusive));a(d)&&(o=o.deltaEnd(d.length));const u=r.$8.fromOffsetPairs(t?t.getEndExclusives():r._3.zero,s?s.getStarts():r._3.max),g=o.intersect(u);l.length>0&&g.getStarts().equals(l[l.length-1].getEndExclusives())?l[l.length-1]=l[l.length-1].join(g):l.push(g)})),l}},82560:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"proto",extensions:[".proto"],aliases:["protobuf","Protocol Buffers"],loader:()=>i.e(10902).then(i.bind(i,10902))})},83069:(e,t,i)=>{"use strict";i.d(t,{y:()=>s});class s{constructor(e,t){this.lineNumber=e,this.column=t}with(e=this.lineNumber,t=this.column){return e===this.lineNumber&&t===this.column?this:new s(e,t)}delta(e=0,t=0){return this.with(this.lineNumber+e,this.column+t)}equals(e){return s.equals(this,e)}static equals(e,t){return!e&&!t||!!e&&!!t&&e.lineNumber===t.lineNumber&&e.column===t.column}isBefore(e){return s.isBefore(this,e)}static isBefore(e,t){return e.lineNumber{"use strict";(0,i(34918).K)({id:"ini",extensions:[".ini",".properties",".gitconfig"],filenames:["config",".gitattributes",".gitconfig",".editorconfig"],aliases:["Ini","ini"],loader:()=>i.e(54678).then(i.bind(i,54678))})},83619:(e,t,i)=>{"use strict";i.d(t,{G$:()=>c,Of:()=>r,r0:()=>o,rr:()=>a});var s=i(78209);class n{constructor(e,t,i=t){this.modifierLabels=[null],this.modifierLabels[2]=e,this.modifierLabels[1]=t,this.modifierLabels[3]=i}toLabel(e,t,i){if(0===t.length)return null;const s=[];for(let n=0,r=t.length;n{"use strict";i.d(t,{$w:()=>ae,SV:()=>ce,aj:()=>oe});const{entries:s,setPrototypeOf:n,isFrozen:r,getPrototypeOf:o,getOwnPropertyDescriptor:a}=Object;let{freeze:c,seal:l,create:h}=Object,{apply:d,construct:u}="undefined"!==typeof Reflect&&Reflect;c||(c=function(e){return e}),l||(l=function(e){return e}),d||(d=function(e,t,i){return e.apply(t,i)}),u||(u=function(e,t){return new e(...t)});const g=L(Array.prototype.forEach),p=L(Array.prototype.pop),m=L(Array.prototype.push),f=L(String.prototype.toLowerCase),_=L(String.prototype.toString),v=L(String.prototype.match),C=L(String.prototype.replace),E=L(String.prototype.indexOf),b=L(String.prototype.trim),S=L(Object.prototype.hasOwnProperty),y=L(RegExp.prototype.test),w=(R=TypeError,function(){for(var e=arguments.length,t=new Array(e),i=0;i1?i-1:0),n=1;n2&&void 0!==arguments[2]?arguments[2]:f;n&&n(e,null);let s=t.length;for(;s--;){let n=t[s];if("string"===typeof n){const e=i(n);e!==n&&(r(t)||(t[s]=e),n=e)}e[n]=!0}return e}function x(e){for(let t=0;t/gm),G=l(/\${[\w\W]*}/gm),j=l(/^data-[\-\w.\u00B7-\uFFFF]/),K=l(/^aria-[\-\w]+$/),Y=l(/^(?:(?:(?:f|ht)tps?|mailto|tel|callto|sms|cid|xmpp):|[^a-z]|[a-z+.\-]+(?:[^a-z+.\-:]|$))/i),q=l(/^(?:\w+script|data):/i),$=l(/[\u0000-\u0020\u00A0\u1680\u180E\u2000-\u2029\u205F\u3000]/g),Q=l(/^html$/i),X=l(/^[a-z][.\w]*(-[.\w]+)+$/i);var Z=Object.freeze({__proto__:null,MUSTACHE_EXPR:V,ERB_EXPR:z,TMPLIT_EXPR:G,DATA_ATTR:j,ARIA_ATTR:K,IS_ALLOWED_URI:Y,IS_SCRIPT_OR_DATA:q,ATTR_WHITESPACE:$,DOCTYPE_NAME:Q,CUSTOM_ELEMENT:X});const J=1,ee=3,te=7,ie=8,se=9,ne=function(){return"undefined"===typeof window?null:window};var re=function e(){let t=arguments.length>0&&void 0!==arguments[0]?arguments[0]:ne();const i=t=>e(t);if(i.version="3.1.7",i.removed=[],!t||!t.document||t.document.nodeType!==se)return i.isSupported=!1,i;let{document:n}=t;const r=n,o=r.currentScript,{DocumentFragment:a,HTMLTemplateElement:l,Node:d,Element:u,NodeFilter:R,NamedNodeMap:L=t.NamedNodeMap||t.MozNamedAttrMap,HTMLFormElement:x,DOMParser:V,trustedTypes:z}=t,G=u.prototype,j=A(G,"cloneNode"),K=A(G,"remove"),q=A(G,"nextSibling"),$=A(G,"childNodes"),X=A(G,"parentNode");if("function"===typeof l){const e=n.createElement("template");e.content&&e.content.ownerDocument&&(n=e.content.ownerDocument)}let re,oe="";const{implementation:ae,createNodeIterator:ce,createDocumentFragment:le,getElementsByTagName:he}=n,{importNode:de}=r;let ue={};i.isSupported="function"===typeof s&&"function"===typeof X&&ae&&void 0!==ae.createHTMLDocument;const{MUSTACHE_EXPR:ge,ERB_EXPR:pe,TMPLIT_EXPR:me,DATA_ATTR:fe,ARIA_ATTR:_e,IS_SCRIPT_OR_DATA:ve,ATTR_WHITESPACE:Ce,CUSTOM_ELEMENT:Ee}=Z;let{IS_ALLOWED_URI:be}=Z,Se=null;const ye=T({},[...N,...I,...O,...M,...F]);let we=null;const Re=T({},[...U,...H,...B,...W]);let Le=Object.seal(h(null,{tagNameCheck:{writable:!0,configurable:!1,enumerable:!0,value:null},attributeNameCheck:{writable:!0,configurable:!1,enumerable:!0,value:null},allowCustomizedBuiltInElements:{writable:!0,configurable:!1,enumerable:!0,value:!1}})),Te=null,xe=null,ke=!0,Ae=!0,Ne=!1,Ie=!0,Oe=!1,De=!0,Me=!1,Pe=!1,Fe=!1,Ue=!1,He=!1,Be=!1,We=!0,Ve=!1,ze=!0,Ge=!1,je={},Ke=null;const Ye=T({},["annotation-xml","audio","colgroup","desc","foreignobject","head","iframe","math","mi","mn","mo","ms","mtext","noembed","noframes","noscript","plaintext","script","style","svg","template","thead","title","video","xmp"]);let qe=null;const $e=T({},["audio","video","img","source","image","track"]);let Qe=null;const Xe=T({},["alt","class","for","id","label","name","pattern","placeholder","role","summary","title","value","style","xmlns"]),Ze="http://www.w3.org/1998/Math/MathML",Je="http://www.w3.org/2000/svg",et="http://www.w3.org/1999/xhtml";let tt=et,it=!1,st=null;const nt=T({},[Ze,Je,et],_);let rt=null;const ot=["application/xhtml+xml","text/html"];let at=null,ct=null;const lt=n.createElement("form"),ht=function(e){return e instanceof RegExp||e instanceof Function},dt=function(){let e=arguments.length>0&&void 0!==arguments[0]?arguments[0]:{};if(!ct||ct!==e){if(e&&"object"===typeof e||(e={}),e=k(e),rt=-1===ot.indexOf(e.PARSER_MEDIA_TYPE)?"text/html":e.PARSER_MEDIA_TYPE,at="application/xhtml+xml"===rt?_:f,Se=S(e,"ALLOWED_TAGS")?T({},e.ALLOWED_TAGS,at):ye,we=S(e,"ALLOWED_ATTR")?T({},e.ALLOWED_ATTR,at):Re,st=S(e,"ALLOWED_NAMESPACES")?T({},e.ALLOWED_NAMESPACES,_):nt,Qe=S(e,"ADD_URI_SAFE_ATTR")?T(k(Xe),e.ADD_URI_SAFE_ATTR,at):Xe,qe=S(e,"ADD_DATA_URI_TAGS")?T(k($e),e.ADD_DATA_URI_TAGS,at):$e,Ke=S(e,"FORBID_CONTENTS")?T({},e.FORBID_CONTENTS,at):Ye,Te=S(e,"FORBID_TAGS")?T({},e.FORBID_TAGS,at):{},xe=S(e,"FORBID_ATTR")?T({},e.FORBID_ATTR,at):{},je=!!S(e,"USE_PROFILES")&&e.USE_PROFILES,ke=!1!==e.ALLOW_ARIA_ATTR,Ae=!1!==e.ALLOW_DATA_ATTR,Ne=e.ALLOW_UNKNOWN_PROTOCOLS||!1,Ie=!1!==e.ALLOW_SELF_CLOSE_IN_ATTR,Oe=e.SAFE_FOR_TEMPLATES||!1,De=!1!==e.SAFE_FOR_XML,Me=e.WHOLE_DOCUMENT||!1,Ue=e.RETURN_DOM||!1,He=e.RETURN_DOM_FRAGMENT||!1,Be=e.RETURN_TRUSTED_TYPE||!1,Fe=e.FORCE_BODY||!1,We=!1!==e.SANITIZE_DOM,Ve=e.SANITIZE_NAMED_PROPS||!1,ze=!1!==e.KEEP_CONTENT,Ge=e.IN_PLACE||!1,be=e.ALLOWED_URI_REGEXP||Y,tt=e.NAMESPACE||et,Le=e.CUSTOM_ELEMENT_HANDLING||{},e.CUSTOM_ELEMENT_HANDLING&&ht(e.CUSTOM_ELEMENT_HANDLING.tagNameCheck)&&(Le.tagNameCheck=e.CUSTOM_ELEMENT_HANDLING.tagNameCheck),e.CUSTOM_ELEMENT_HANDLING&&ht(e.CUSTOM_ELEMENT_HANDLING.attributeNameCheck)&&(Le.attributeNameCheck=e.CUSTOM_ELEMENT_HANDLING.attributeNameCheck),e.CUSTOM_ELEMENT_HANDLING&&"boolean"===typeof e.CUSTOM_ELEMENT_HANDLING.allowCustomizedBuiltInElements&&(Le.allowCustomizedBuiltInElements=e.CUSTOM_ELEMENT_HANDLING.allowCustomizedBuiltInElements),Oe&&(Ae=!1),He&&(Ue=!0),je&&(Se=T({},F),we=[],!0===je.html&&(T(Se,N),T(we,U)),!0===je.svg&&(T(Se,I),T(we,H),T(we,W)),!0===je.svgFilters&&(T(Se,O),T(we,H),T(we,W)),!0===je.mathMl&&(T(Se,M),T(we,B),T(we,W))),e.ADD_TAGS&&(Se===ye&&(Se=k(Se)),T(Se,e.ADD_TAGS,at)),e.ADD_ATTR&&(we===Re&&(we=k(we)),T(we,e.ADD_ATTR,at)),e.ADD_URI_SAFE_ATTR&&T(Qe,e.ADD_URI_SAFE_ATTR,at),e.FORBID_CONTENTS&&(Ke===Ye&&(Ke=k(Ke)),T(Ke,e.FORBID_CONTENTS,at)),ze&&(Se["#text"]=!0),Me&&T(Se,["html","head","body"]),Se.table&&(T(Se,["tbody"]),delete Te.tbody),e.TRUSTED_TYPES_POLICY){if("function"!==typeof e.TRUSTED_TYPES_POLICY.createHTML)throw w('TRUSTED_TYPES_POLICY configuration option must provide a "createHTML" hook.');if("function"!==typeof e.TRUSTED_TYPES_POLICY.createScriptURL)throw w('TRUSTED_TYPES_POLICY configuration option must provide a "createScriptURL" hook.');re=e.TRUSTED_TYPES_POLICY,oe=re.createHTML("")}else void 0===re&&(re=function(e,t){if("object"!==typeof e||"function"!==typeof e.createPolicy)return null;let i=null;const s="data-tt-policy-suffix";t&&t.hasAttribute(s)&&(i=t.getAttribute(s));const n="dompurify"+(i?"#"+i:"");try{return e.createPolicy(n,{createHTML:e=>e,createScriptURL:e=>e})}catch(r){return console.warn("TrustedTypes policy "+n+" could not be created."),null}}(z,o)),null!==re&&"string"===typeof oe&&(oe=re.createHTML(""));c&&c(e),ct=e}},ut=T({},["mi","mo","mn","ms","mtext"]),gt=T({},["annotation-xml"]),pt=T({},["title","style","font","a","script"]),mt=T({},[...I,...O,...D]),ft=T({},[...M,...P]),_t=function(e){m(i.removed,{element:e});try{X(e).removeChild(e)}catch(t){K(e)}},vt=function(e,t){try{m(i.removed,{attribute:t.getAttributeNode(e),from:t})}catch(s){m(i.removed,{attribute:null,from:t})}if(t.removeAttribute(e),"is"===e&&!we[e])if(Ue||He)try{_t(t)}catch(s){}else try{t.setAttribute(e,"")}catch(s){}},Ct=function(e){let t=null,i=null;if(Fe)e=""+e;else{const t=v(e,/^[\r\n\t ]+/);i=t&&t[0]}"application/xhtml+xml"===rt&&tt===et&&(e=''+e+"");const s=re?re.createHTML(e):e;if(tt===et)try{t=(new V).parseFromString(s,rt)}catch(o){}if(!t||!t.documentElement){t=ae.createDocument(tt,"template",null);try{t.documentElement.innerHTML=it?oe:s}catch(o){}}const r=t.body||t.documentElement;return e&&i&&r.insertBefore(n.createTextNode(i),r.childNodes[0]||null),tt===et?he.call(t,Me?"html":"body")[0]:Me?t.documentElement:r},Et=function(e){return ce.call(e.ownerDocument||e,e,R.SHOW_ELEMENT|R.SHOW_COMMENT|R.SHOW_TEXT|R.SHOW_PROCESSING_INSTRUCTION|R.SHOW_CDATA_SECTION,null)},bt=function(e){return e instanceof x&&("string"!==typeof e.nodeName||"string"!==typeof e.textContent||"function"!==typeof e.removeChild||!(e.attributes instanceof L)||"function"!==typeof e.removeAttribute||"function"!==typeof e.setAttribute||"string"!==typeof e.namespaceURI||"function"!==typeof e.insertBefore||"function"!==typeof e.hasChildNodes)},St=function(e){return"function"===typeof d&&e instanceof d},yt=function(e,t,s){ue[e]&&g(ue[e],(e=>{e.call(i,t,s,ct)}))},wt=function(e){let t=null;if(yt("beforeSanitizeElements",e,null),bt(e))return _t(e),!0;const s=at(e.nodeName);if(yt("uponSanitizeElement",e,{tagName:s,allowedTags:Se}),e.hasChildNodes()&&!St(e.firstElementChild)&&y(/<[/\w]/g,e.innerHTML)&&y(/<[/\w]/g,e.textContent))return _t(e),!0;if(e.nodeType===te)return _t(e),!0;if(De&&e.nodeType===ie&&y(/<[/\w]/g,e.data))return _t(e),!0;if(!Se[s]||Te[s]){if(!Te[s]&&Lt(s)){if(Le.tagNameCheck instanceof RegExp&&y(Le.tagNameCheck,s))return!1;if(Le.tagNameCheck instanceof Function&&Le.tagNameCheck(s))return!1}if(ze&&!Ke[s]){const t=X(e)||e.parentNode,i=$(e)||e.childNodes;if(i&&t){for(let s=i.length-1;s>=0;--s){const n=j(i[s],!0);n.__removalCount=(e.__removalCount||0)+1,t.insertBefore(n,q(e))}}}return _t(e),!0}return e instanceof u&&!function(e){let t=X(e);t&&t.tagName||(t={namespaceURI:tt,tagName:"template"});const i=f(e.tagName),s=f(t.tagName);return!!st[e.namespaceURI]&&(e.namespaceURI===Je?t.namespaceURI===et?"svg"===i:t.namespaceURI===Ze?"svg"===i&&("annotation-xml"===s||ut[s]):Boolean(mt[i]):e.namespaceURI===Ze?t.namespaceURI===et?"math"===i:t.namespaceURI===Je?"math"===i&>[s]:Boolean(ft[i]):e.namespaceURI===et?!(t.namespaceURI===Je&&!gt[s])&&!(t.namespaceURI===Ze&&!ut[s])&&!ft[i]&&(pt[i]||!mt[i]):!("application/xhtml+xml"!==rt||!st[e.namespaceURI]))}(e)?(_t(e),!0):"noscript"!==s&&"noembed"!==s&&"noframes"!==s||!y(/<\/no(script|embed|frames)/i,e.innerHTML)?(Oe&&e.nodeType===ee&&(t=e.textContent,g([ge,pe,me],(e=>{t=C(t,e," ")})),e.textContent!==t&&(m(i.removed,{element:e.cloneNode()}),e.textContent=t)),yt("afterSanitizeElements",e,null),!1):(_t(e),!0)},Rt=function(e,t,i){if(We&&("id"===t||"name"===t)&&(i in n||i in lt))return!1;if(Ae&&!xe[t]&&y(fe,t));else if(ke&&y(_e,t));else if(!we[t]||xe[t]){if(!(Lt(e)&&(Le.tagNameCheck instanceof RegExp&&y(Le.tagNameCheck,e)||Le.tagNameCheck instanceof Function&&Le.tagNameCheck(e))&&(Le.attributeNameCheck instanceof RegExp&&y(Le.attributeNameCheck,t)||Le.attributeNameCheck instanceof Function&&Le.attributeNameCheck(t))||"is"===t&&Le.allowCustomizedBuiltInElements&&(Le.tagNameCheck instanceof RegExp&&y(Le.tagNameCheck,i)||Le.tagNameCheck instanceof Function&&Le.tagNameCheck(i))))return!1}else if(Qe[t]);else if(y(be,C(i,Ce,"")));else if("src"!==t&&"xlink:href"!==t&&"href"!==t||"script"===e||0!==E(i,"data:")||!qe[e]){if(Ne&&!y(ve,C(i,Ce,"")));else if(i)return!1}else;return!0},Lt=function(e){return"annotation-xml"!==e&&v(e,Ee)},Tt=function(e){yt("beforeSanitizeAttributes",e,null);const{attributes:t}=e;if(!t)return;const s={attrName:"",attrValue:"",keepAttr:!0,allowedAttributes:we};let n=t.length;for(;n--;){const o=t[n],{name:a,namespaceURI:c,value:l}=o,h=at(a);let d="value"===a?l:b(l);if(s.attrName=h,s.attrValue=d,s.keepAttr=!0,s.forceKeepAttr=void 0,yt("uponSanitizeAttribute",e,s),d=s.attrValue,s.forceKeepAttr)continue;if(vt(a,e),!s.keepAttr)continue;if(!Ie&&y(/\/>/i,d)){vt(a,e);continue}Oe&&g([ge,pe,me],(e=>{d=C(d,e," ")}));const u=at(e.nodeName);if(Rt(u,h,d))if(!Ve||"id"!==h&&"name"!==h||(vt(a,e),d="user-content-"+d),De&&y(/((--!?|])>)|<\/(style|title)/i,d))vt(a,e);else{if(re&&"object"===typeof z&&"function"===typeof z.getAttributeType)if(c);else switch(z.getAttributeType(u,h)){case"TrustedHTML":d=re.createHTML(d);break;case"TrustedScriptURL":d=re.createScriptURL(d)}try{c?e.setAttributeNS(c,a,d):e.setAttribute(a,d),bt(e)?_t(e):p(i.removed)}catch(r){}}}yt("afterSanitizeAttributes",e,null)},xt=function e(t){let i=null;const s=Et(t);for(yt("beforeSanitizeShadowDOM",t,null);i=s.nextNode();)yt("uponSanitizeShadowNode",i,null),wt(i)||(i.content instanceof a&&e(i.content),Tt(i));yt("afterSanitizeShadowDOM",t,null)};return i.sanitize=function(e){let t=arguments.length>1&&void 0!==arguments[1]?arguments[1]:{},s=null,n=null,o=null,c=null;if(it=!e,it&&(e="\x3c!--\x3e"),"string"!==typeof e&&!St(e)){if("function"!==typeof e.toString)throw w("toString is not a function");if("string"!==typeof(e=e.toString()))throw w("dirty is not a string, aborting")}if(!i.isSupported)return e;if(Pe||dt(t),i.removed=[],"string"===typeof e&&(Ge=!1),Ge){if(e.nodeName){const t=at(e.nodeName);if(!Se[t]||Te[t])throw w("root node is forbidden and cannot be sanitized in-place")}}else if(e instanceof d)s=Ct("\x3c!----\x3e"),n=s.ownerDocument.importNode(e,!0),n.nodeType===J&&"BODY"===n.nodeName||"HTML"===n.nodeName?s=n:s.appendChild(n);else{if(!Ue&&!Oe&&!Me&&-1===e.indexOf("<"))return re&&Be?re.createHTML(e):e;if(s=Ct(e),!s)return Ue?null:Be?oe:""}s&&Fe&&_t(s.firstChild);const l=Et(Ge?e:s);for(;o=l.nextNode();)wt(o)||(o.content instanceof a&&xt(o.content),Tt(o));if(Ge)return e;if(Ue){if(He)for(c=le.call(s.ownerDocument);s.firstChild;)c.appendChild(s.firstChild);else c=s;return(we.shadowroot||we.shadowrootmode)&&(c=de.call(r,c,!0)),c}let h=Me?s.outerHTML:s.innerHTML;return Me&&Se["!doctype"]&&s.ownerDocument&&s.ownerDocument.doctype&&s.ownerDocument.doctype.name&&y(Q,s.ownerDocument.doctype.name)&&(h="\n"+h),Oe&&g([ge,pe,me],(e=>{h=C(h,e," ")})),re&&Be?re.createHTML(h):h},i.setConfig=function(){dt(arguments.length>0&&void 0!==arguments[0]?arguments[0]:{}),Pe=!0},i.clearConfig=function(){ct=null,Pe=!1},i.isValidAttribute=function(e,t,i){ct||dt({});const s=at(e),n=at(t);return Rt(s,n,i)},i.addHook=function(e,t){"function"===typeof t&&(ue[e]=ue[e]||[],m(ue[e],t))},i.removeHook=function(e){if(ue[e])return p(ue[e])},i.removeHooks=function(e){ue[e]&&(ue[e]=[])},i.removeAllHooks=function(){ue={}},i}();re.version,re.isSupported;const oe=re.sanitize,ae=(re.setConfig,re.clearConfig,re.isValidAttribute,re.addHook),ce=re.removeHook;re.removeHooks,re.removeAllHooks},83823:(e,t,i)=>{e.exports=function(e){const t=i(94297),s={string:null,"yql.string":null};function n(e,t){const i=e[0],n=t[0];return(Object.prototype.hasOwnProperty.call(s,i.$type)&&Object.prototype.hasOwnProperty.call(s,n.$type)&&i.$value)>n.$value?1:-1}return function(i,s,r){let o=i.slice().sort(n);const a=s.limitMapLength>0&&i.length>s.limitMapLength;return a&&(o=o.slice(0,s.limitMapLength-1)),o.map((function(i){let n="";return n+=e(i[0],s,r+1),n+=t.getKeyValueSeparator(s),n+=e(i[1],s,r+1),n})).concat(a?["... "+(i.length-s.limitMapLength+1)+" hidden keys"]:[]).join(t.getExpressionTerminator(s)+t.getIndent(s,r))}}},83844:(e,t,i)=>{"use strict";i.d(t,{Bb:()=>h,Fd:()=>g,Gu:()=>d,HP:()=>u,Hz:()=>E,JO:()=>v,a:()=>_,e$:()=>f,oG:()=>b,x1:()=>m,yL:()=>C});var s=i(66782),n=i(90766),r=i(47661),o=i(41234),a=i(78748),c=i(46359),l=i(78209);function h(e){return`--vscode-${e.replace(/\./g,"-")}`}function d(e){return`var(${h(e)})`}function u(e,t){return`var(${h(e)}, ${t})`}const g={ColorContribution:"base.contributions.colors"};const p=new class{constructor(){this._onDidChangeSchema=new o.vl,this.onDidChangeSchema=this._onDidChangeSchema.event,this.colorSchema={type:"object",properties:{}},this.colorReferenceSchema={type:"string",enum:[],enumDescriptions:[]},this.colorsById={}}registerColor(e,t,i,s=!1,n){const r={id:e,description:i,defaults:t,needsTransparency:s,deprecationMessage:n};this.colorsById[e]=r;const o={type:"string",format:"color-hex",defaultSnippets:[{body:"${1:#ff0000}"}]};return n&&(o.deprecationMessage=n),s&&(o.pattern="^#(?:(?[0-9a-fA-f]{3}[0-9a-eA-E])|(?:[0-9a-fA-F]{6}(?:(?![fF]{2})(?:[0-9a-fA-F]{2}))))?$",o.patternErrorMessage=l.kg("transparecyRequired","This color must be transparent or it will obscure content")),this.colorSchema.properties[e]={description:i,oneOf:[o,{type:"string",const:"default",description:l.kg("useDefault","Use the default color.")}]},this.colorReferenceSchema.enum.push(e),this.colorReferenceSchema.enumDescriptions.push(i),this._onDidChangeSchema.fire(),e}getColors(){return Object.keys(this.colorsById).map((e=>this.colorsById[e]))}resolveDefaultColor(e,t){const i=this.colorsById[e];if(i?.defaults){return S(null!==(s=i.defaults)&&"object"===typeof s&&"light"in s&&"dark"in s?i.defaults[t.type]:i.defaults,t)}var s}getColorSchema(){return this.colorSchema}toString(){return Object.keys(this.colorsById).sort(((e,t)=>{const i=-1===e.indexOf(".")?0:1,s=-1===t.indexOf(".")?0:1;return i!==s?i-s:e.localeCompare(t)})).map((e=>`- \`${e}\`: ${this.colorsById[e].description}`)).join("\n")}};function m(e,t,i,s,n){return p.registerColor(e,t,i,s,n)}function f(e,t){return{op:0,value:e,factor:t}}function _(e,t){return{op:1,value:e,factor:t}}function v(e,t){return{op:2,value:e,factor:t}}function C(...e){return{op:4,values:e}}function E(e,t,i){return{op:6,if:e,then:t,else:i}}function b(e,t,i,s){return{op:5,value:e,background:t,factor:i,transparency:s}}function S(e,t){if(null!==e)return"string"===typeof e?"#"===e[0]?r.Q1.fromHex(e):t.getColor(e):e instanceof r.Q1?e:"object"===typeof e?function(e,t){switch(e.op){case 0:return S(e.value,t)?.darken(e.factor);case 1:return S(e.value,t)?.lighten(e.factor);case 2:return S(e.value,t)?.transparent(e.factor);case 3:{const i=S(e.background,t);return i?S(e.value,t)?.makeOpaque(i):S(e.value,t)}case 4:for(const i of e.values){const e=S(i,t);if(e)return e}return;case 6:return S(t.defines(e.if)?e.then:e.else,t);case 5:{const i=S(e.value,t);if(!i)return;const s=S(e.background,t);return s?i.isDarkerThan(s)?r.Q1.getLighterColor(i,s,e.factor).transparent(e.transparency):r.Q1.getDarkerColor(i,s,e.factor).transparent(e.transparency):i.transparent(e.factor*e.transparency)}default:throw(0,s.xb)(e)}}(e,t):void 0}c.O.add(g.ColorContribution,p);const y="vscode://schemas/workbench-colors",w=c.O.as(a.F.JSONContribution);w.registerSchema(y,p.getColorSchema());const R=new n.uC((()=>w.notifySchemaChanged(y)),200);p.onDidChangeSchema((()=>{R.isScheduled()||R.schedule()}))},83941:(e,t,i)=>{"use strict";i.d(t,{W6:()=>c,vH:()=>l});var s=i(78209),n=i(41234),r=i(46359),o=i(44320),a=i(1646);const c=new class{constructor(){this._onDidChangeLanguages=new n.vl,this.onDidChangeLanguages=this._onDidChangeLanguages.event,this._languages=[]}registerLanguage(e){return this._languages.push(e),this._onDidChangeLanguages.fire(void 0),{dispose:()=>{for(let t=0,i=this._languages.length;t{"use strict";i.d(t,{uP:()=>h,F1:()=>o});class s{constructor(e,t,i,s){this.originalStart=e,this.originalLength=t,this.modifiedStart=i,this.modifiedLength=s}getOriginalEnd(){return this.originalStart+this.originalLength}getModifiedEnd(){return this.modifiedStart+this.modifiedLength}}var n=i(85600);class r{constructor(e){this.source=e}getElements(){const e=this.source,t=new Int32Array(e.length);for(let i=0,s=e.length;i0||this.m_modifiedCount>0)&&this.m_changes.push(new s(this.m_originalStart,this.m_originalCount,this.m_modifiedStart,this.m_modifiedCount)),this.m_originalCount=0,this.m_modifiedCount=0,this.m_originalStart=1073741824,this.m_modifiedStart=1073741824}AddOriginalElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_originalCount++}AddModifiedElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_modifiedCount++}getChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes}getReverseChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes.reverse(),this.m_changes}}class h{constructor(e,t,i=null){this.ContinueProcessingPredicate=i,this._originalSequence=e,this._modifiedSequence=t;const[s,n,r]=h._getElements(e),[o,a,c]=h._getElements(t);this._hasStrings=r&&c,this._originalStringElements=s,this._originalElementsOrHash=n,this._modifiedStringElements=o,this._modifiedElementsOrHash=a,this.m_forwardHistory=[],this.m_reverseHistory=[]}static _isStringArray(e){return e.length>0&&"string"===typeof e[0]}static _getElements(e){const t=e.getElements();if(h._isStringArray(t)){const e=new Int32Array(t.length);for(let i=0,s=t.length;i=e&&n>=i&&this.ElementsAreEqual(t,n);)t--,n--;if(e>t||i>n){let r;return i<=n?(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),r=[new s(e,0,i,n-i+1)]):e<=t?(a.Assert(i===n+1,"modifiedStart should only be one more than modifiedEnd"),r=[new s(e,t-e+1,i,0)]):(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),a.Assert(i===n+1,"modifiedStart should only be one more than modifiedEnd"),r=[]),r}const o=[0],c=[0],l=this.ComputeRecursionPoint(e,t,i,n,o,c,r),h=o[0],d=c[0];if(null!==l)return l;if(!r[0]){const o=this.ComputeDiffRecursive(e,h,i,d,r);let a=[];return a=r[0]?[new s(h+1,t-(h+1)+1,d+1,n-(d+1)+1)]:this.ComputeDiffRecursive(h+1,t,d+1,n,r),this.ConcatenateChanges(o,a)}return[new s(e,t-e+1,i,n-i+1)]}WALKTRACE(e,t,i,n,r,o,a,c,h,d,u,g,p,m,f,_,v,C){let E=null,b=null,S=new l,y=t,w=i,R=p[0]-_[0]-n,L=-1073741824,T=this.m_forwardHistory.length-1;do{const t=R+e;t===y||t=0&&(e=(h=this.m_forwardHistory[T])[0],y=1,w=h.length-1)}while(--T>=-1);if(E=S.getReverseChanges(),C[0]){let e=p[0]+1,t=_[0]+1;if(null!==E&&E.length>0){const i=E[E.length-1];e=Math.max(e,i.getOriginalEnd()),t=Math.max(t,i.getModifiedEnd())}b=[new s(e,g-e+1,t,f-t+1)]}else{S=new l,y=o,w=a,R=p[0]-_[0]-c,L=1073741824,T=v?this.m_reverseHistory.length-1:this.m_reverseHistory.length-2;do{const e=R+r;e===y||e=d[e+1]?(m=(u=d[e+1]-1)-R-c,u>L&&S.MarkNextChange(),L=u+1,S.AddOriginalElement(u+1,m+1),R=e+1-r):(m=(u=d[e-1])-R-c,u>L&&S.MarkNextChange(),L=u,S.AddModifiedElement(u+1,m+1),R=e-1-r),T>=0&&(r=(d=this.m_reverseHistory[T])[0],y=1,w=d.length-1)}while(--T>=-1);b=S.getChanges()}return this.ConcatenateChanges(E,b)}ComputeRecursionPoint(e,t,i,n,r,o,a){let l=0,h=0,d=0,u=0,g=0,p=0;e--,i--,r[0]=0,o[0]=0,this.m_forwardHistory=[],this.m_reverseHistory=[];const m=t-e+(n-i),f=m+1,_=new Int32Array(f),v=new Int32Array(f),C=n-i,E=t-e,b=e-i,S=t-n,y=(E-C)%2===0;_[C]=e,v[E]=t,a[0]=!1;for(let w=1;w<=m/2+1;w++){let m=0,R=0;d=this.ClipDiagonalBound(C-w,w,C,f),u=this.ClipDiagonalBound(C+w,w,C,f);for(let e=d;e<=u;e+=2){l=e===d||em+R&&(m=l,R=h),!y&&Math.abs(e-E)<=w-1&&l>=v[e])return r[0]=l,o[0]=h,i<=v[e]&&w<=1448?this.WALKTRACE(C,d,u,b,E,g,p,S,_,v,l,t,r,h,n,o,y,a):null}const L=(m-e+(R-i)-w)/2;if(null!==this.ContinueProcessingPredicate&&!this.ContinueProcessingPredicate(m,L))return a[0]=!0,r[0]=m,o[0]=R,L>0&&w<=1448?this.WALKTRACE(C,d,u,b,E,g,p,S,_,v,l,t,r,h,n,o,y,a):(e++,i++,[new s(e,t-e+1,i,n-i+1)]);g=this.ClipDiagonalBound(E-w,w,E,f),p=this.ClipDiagonalBound(E+w,w,E,f);for(let s=g;s<=p;s+=2){l=s===g||s=v[s+1]?v[s+1]-1:v[s-1],h=l-(s-E)-S;const c=l;for(;l>e&&h>i&&this.ElementsAreEqual(l,h);)l--,h--;if(v[s]=l,y&&Math.abs(s-C)<=w&&l<=_[s])return r[0]=l,o[0]=h,c>=_[s]&&w<=1448?this.WALKTRACE(C,d,u,b,E,g,p,S,_,v,l,t,r,h,n,o,y,a):null}if(w<=1447){let e=new Int32Array(u-d+2);e[0]=C-d+1,c.Copy2(_,d,e,1,u-d+1),this.m_forwardHistory.push(e),e=new Int32Array(p-g+2),e[0]=E-g+1,c.Copy2(v,g,e,1,p-g+1),this.m_reverseHistory.push(e)}}return this.WALKTRACE(C,d,u,b,E,g,p,S,_,v,l,t,r,h,n,o,y,a)}PrettifyChanges(e){for(let t=0;t0,o=i.modifiedLength>0;for(;i.originalStart+i.originalLength=0;t--){const i=e[t];let s=0,n=0;if(t>0){const i=e[t-1];s=i.originalStart+i.originalLength,n=i.modifiedStart+i.modifiedLength}const r=i.originalLength>0,o=i.modifiedLength>0;let a=0,c=this._boundaryScore(i.originalStart,i.originalLength,i.modifiedStart,i.modifiedLength);for(let e=1;;e++){const t=i.originalStart-e,l=i.modifiedStart-e;if(tc&&(c=h,a=e)}i.originalStart-=a,i.modifiedStart-=a;const l=[null];t>0&&this.ChangesOverlap(e[t-1],e[t],l)&&(e[t-1]=l[0],e.splice(t,1),t++)}if(this._hasStrings)for(let t=1,i=e.length;t0&&t>a&&(a=t,c=h,l=e)}return a>0?[c,l]:null}_contiguousSequenceScore(e,t,i){let s=0;for(let n=0;n=this._originalElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._originalStringElements[e])}_OriginalRegionIsBoundary(e,t){if(this._OriginalIsBoundary(e)||this._OriginalIsBoundary(e-1))return!0;if(t>0){const i=e+t;if(this._OriginalIsBoundary(i-1)||this._OriginalIsBoundary(i))return!0}return!1}_ModifiedIsBoundary(e){return e<=0||e>=this._modifiedElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._modifiedStringElements[e])}_ModifiedRegionIsBoundary(e,t){if(this._ModifiedIsBoundary(e)||this._ModifiedIsBoundary(e-1))return!0;if(t>0){const i=e+t;if(this._ModifiedIsBoundary(i-1)||this._ModifiedIsBoundary(i))return!0}return!1}_boundaryScore(e,t,i,s){return(this._OriginalRegionIsBoundary(e,t)?1:0)+(this._ModifiedRegionIsBoundary(i,s)?1:0)}ConcatenateChanges(e,t){const i=[];if(0===e.length||0===t.length)return t.length>0?t:e;if(this.ChangesOverlap(e[e.length-1],t[0],i)){const s=new Array(e.length+t.length-1);return c.Copy(e,0,s,0,e.length-1),s[e.length-1]=i[0],c.Copy(t,1,s,e.length,t.length-1),s}{const i=new Array(e.length+t.length);return c.Copy(e,0,i,0,e.length),c.Copy(t,0,i,e.length,t.length),i}}ChangesOverlap(e,t,i){if(a.Assert(e.originalStart<=t.originalStart,"Left change is not less than or equal to right change"),a.Assert(e.modifiedStart<=t.modifiedStart,"Left change is not less than or equal to right change"),e.originalStart+e.originalLength>=t.originalStart||e.modifiedStart+e.modifiedLength>=t.modifiedStart){const n=e.originalStart;let r=e.originalLength;const o=e.modifiedStart;let a=e.modifiedLength;return e.originalStart+e.originalLength>=t.originalStart&&(r=t.originalStart+t.originalLength-e.originalStart),e.modifiedStart+e.modifiedLength>=t.modifiedStart&&(a=t.modifiedStart+t.modifiedLength-e.modifiedStart),i[0]=new s(n,r,o,a),!0}return i[0]=null,!1}ClipDiagonalBound(e,t,i,s){if(e>=0&&e{"use strict";i.d(t,{Mo:()=>l,ad:()=>n,gD:()=>c,iB:()=>o,kW:()=>r,pG:()=>s});const s=(0,i(63591).u1)("configurationService");function n(e,t){const i=Object.create(null);for(const s in e)r(i,s,e[s],t);return i}function r(e,t,i,s){const n=t.split("."),r=n.pop();let o=e;for(let c=0;c{"use strict";i.d(t,{d:()=>s});class s{constructor(e,t=[],i=!1){this.ctor=e,this.staticArguments=t,this.supportsDelayedInstantiation=i}}},84084:(e,t,i)=>{"use strict";i.d(t,{M:()=>o});var s=i(25890),n=i(94650),r=i(19131);function o(e,t){if(0===e.length)return t;if(0===t.length)return e;const i=new s.j3(c(e)),o=c(t);o.push({modified:!1,lengthBefore:void 0,lengthAfter:void 0});let l=i.dequeue();function h(e){if(void 0===e){const e=i.takeWhile((e=>!0))||[];return l&&e.unshift(l),e}const t=[];for(;l&&!(0,r.Vh)(e);){const[s,n]=l.splitAt(e);t.push(s),e=(0,r.MS)(s.lengthAfter,e),l=n??i.dequeue()}return(0,r.Vh)(e)||t.push(new a(!1,e,e)),t}const d=[];function u(e,t,i){if(d.length>0&&(0,r.wP)(d[d.length-1].endOffset,e)){const e=d[d.length-1];d[d.length-1]=new n.c(e.startOffset,t,(0,r.QB)(e.newLength,i))}else d.push({startOffset:e,endOffset:t,newLength:i})}let g=r.Vp;for(const s of o){const e=h(s.lengthBefore);if(s.modified){const t=(0,r.pW)(e,(e=>e.lengthBefore)),i=(0,r.QB)(g,t);u(g,i,s.lengthAfter),g=i}else for(const t of e){const e=g;g=(0,r.QB)(g,t.lengthBefore),t.modified&&u(e,g,t.lengthAfter)}}return d}class a{constructor(e,t,i){this.modified=e,this.lengthBefore=t,this.lengthAfter=i}splitAt(e){const t=(0,r.MS)(e,this.lengthAfter);return(0,r.wP)(t,r.Vp)?[this,void 0]:this.modified?[new a(this.modified,this.lengthBefore,e),new a(this.modified,r.Vp,t)]:[new a(this.modified,e,e),new a(this.modified,t,t)]}toString(){return`${this.modified?"M":"U"}:${(0,r.l4)(this.lengthBefore)} -> ${(0,r.l4)(this.lengthAfter)}`}}function c(e){const t=[];let i=r.Vp;for(const s of e){const e=(0,r.MS)(i,s.startOffset);(0,r.Vh)(e)||t.push(new a(!1,e,e));const n=(0,r.MS)(s.startOffset,s.endOffset);t.push(new a(!0,n,s.newLength)),i=s.endOffset}return t}},84226:(e,t,i)=>{"use strict";i.d(t,{zn:()=>O,x2:()=>D,j6:()=>U,RL:()=>P,zl:()=>V,n6:()=>z,z0:()=>H,_X:()=>B,e3:()=>W});var s=i(8597),n=i(11799),r=i(36921),o=i(10350),a=i(25689),c=i(47661),l=i(41234),h=i(10146),d=i(31450),u=i(80301),g=i(29163),p=i(92403),m=i(96032),f=i(5662),_=i(36677),v=i(87289);const C=new c.Q1(new c.bU(0,122,204)),E={showArrow:!0,showFrame:!0,className:"",frameColor:C,arrowColor:C,keepEditorSelection:!1};class b{constructor(e,t,i,s,n,r,o,a){this.id="",this.domNode=e,this.afterLineNumber=t,this.afterColumn=i,this.heightInLines=s,this.showInHiddenAreas=o,this.ordinal=a,this._onDomNodeTop=n,this._onComputedHeight=r}onDomNodeTop(e){this._onDomNodeTop(e)}onComputedHeight(e){this._onComputedHeight(e)}}class S{constructor(e,t){this._id=e,this._domNode=t}getId(){return this._id}getDomNode(){return this._domNode}getPosition(){return null}}class y{static{this._IdGenerator=new m.n(".arrow-decoration-")}constructor(e){this._editor=e,this._ruleName=y._IdGenerator.nextId(),this._decorations=this._editor.createDecorationsCollection(),this._color=null,this._height=-1}dispose(){this.hide(),s.U2(this._ruleName)}set color(e){this._color!==e&&(this._color=e,this._updateStyle())}set height(e){this._height!==e&&(this._height=e,this._updateStyle())}_updateStyle(){s.U2(this._ruleName),s.Wt(`.monaco-editor ${this._ruleName}`,`border-style: solid; border-color: transparent; border-bottom-color: ${this._color}; border-width: ${this._height}px; bottom: -${this._height}px !important; margin-left: -${this._height}px; `)}show(e){1===e.column&&(e={lineNumber:e.lineNumber,column:2}),this._decorations.set([{range:_.Q.fromPositions(e),options:{description:"zone-widget-arrow",className:this._ruleName,stickiness:1}}])}hide(){this._decorations.clear()}}class w{constructor(e,t={}){this._arrow=null,this._overlayWidget=null,this._resizeSash=null,this._viewZone=null,this._disposables=new f.Cm,this.container=null,this._isShowing=!1,this.editor=e,this._positionMarkerId=this.editor.createDecorationsCollection(),this.options=h.Go(t),h.co(this.options,E,!1),this.domNode=document.createElement("div"),this.options.isAccessible||(this.domNode.setAttribute("aria-hidden","true"),this.domNode.setAttribute("role","presentation")),this._disposables.add(this.editor.onDidLayoutChange((e=>{const t=this._getWidth(e);this.domNode.style.width=t+"px",this.domNode.style.left=this._getLeft(e)+"px",this._onWidth(t)})))}dispose(){this._overlayWidget&&(this.editor.removeOverlayWidget(this._overlayWidget),this._overlayWidget=null),this._viewZone&&this.editor.changeViewZones((e=>{this._viewZone&&e.removeZone(this._viewZone.id),this._viewZone=null})),this._positionMarkerId.clear(),this._disposables.dispose()}create(){this.domNode.classList.add("zone-widget"),this.options.className&&this.domNode.classList.add(this.options.className),this.container=document.createElement("div"),this.container.classList.add("zone-widget-container"),this.domNode.appendChild(this.container),this.options.showArrow&&(this._arrow=new y(this.editor),this._disposables.add(this._arrow)),this._fillContainer(this.container),this._initSash(),this._applyStyles()}style(e){e.frameColor&&(this.options.frameColor=e.frameColor),e.arrowColor&&(this.options.arrowColor=e.arrowColor),this._applyStyles()}_applyStyles(){if(this.container&&this.options.frameColor){const e=this.options.frameColor.toString();this.container.style.borderTopColor=e,this.container.style.borderBottomColor=e}if(this._arrow&&this.options.arrowColor){const e=this.options.arrowColor.toString();this._arrow.color=e}}_getWidth(e){return e.width-e.minimap.minimapWidth-e.verticalScrollbarWidth}_getLeft(e){return e.minimap.minimapWidth>0&&0===e.minimap.minimapLeft?e.minimap.minimapWidth:0}_onViewZoneTop(e){this.domNode.style.top=e+"px"}_onViewZoneHeight(e){if(this.domNode.style.height=`${e}px`,this.container){const t=e-this._decoratingElementsHeight();this.container.style.height=`${t}px`;const i=this.editor.getLayoutInfo();this._doLayout(t,this._getWidth(i))}this._resizeSash?.layout()}get position(){const e=this._positionMarkerId.getRange(0);if(e)return e.getStartPosition()}show(e,t){const i=_.Q.isIRange(e)?_.Q.lift(e):_.Q.fromPositions(e);this._isShowing=!0,this._showImpl(i,t),this._isShowing=!1,this._positionMarkerId.set([{range:i,options:v.kI.EMPTY}])}hide(){this._viewZone&&(this.editor.changeViewZones((e=>{this._viewZone&&e.removeZone(this._viewZone.id)})),this._viewZone=null),this._overlayWidget&&(this.editor.removeOverlayWidget(this._overlayWidget),this._overlayWidget=null),this._arrow?.hide(),this._positionMarkerId.clear()}_decoratingElementsHeight(){const e=this.editor.getOption(67);let t=0;if(this.options.showArrow){t+=2*Math.round(e/3)}if(this.options.showFrame){t+=2*Math.round(e/9)}return t}_showImpl(e,t){const i=e.getStartPosition(),s=this.editor.getLayoutInfo(),n=this._getWidth(s);this.domNode.style.width=`${n}px`,this.domNode.style.left=this._getLeft(s)+"px";const r=document.createElement("div");r.style.overflow="hidden";const o=this.editor.getOption(67);if(!this.options.allowUnlimitedHeight){const e=Math.max(12,this.editor.getLayoutInfo().height/o*.8);t=Math.min(t,e)}let a=0,c=0;if(this._arrow&&this.options.showArrow&&(a=Math.round(o/3),this._arrow.height=a,this._arrow.show(i)),this.options.showFrame&&(c=Math.round(o/9)),this.editor.changeViewZones((e=>{this._viewZone&&e.removeZone(this._viewZone.id),this._overlayWidget&&(this.editor.removeOverlayWidget(this._overlayWidget),this._overlayWidget=null),this.domNode.style.top="-1000px",this._viewZone=new b(r,i.lineNumber,i.column,t,(e=>this._onViewZoneTop(e)),(e=>this._onViewZoneHeight(e)),this.options.showInHiddenAreas,this.options.ordinal),this._viewZone.id=e.addZone(this._viewZone),this._overlayWidget=new S("vs.editor.contrib.zoneWidget"+this._viewZone.id,this.domNode),this.editor.addOverlayWidget(this._overlayWidget)})),this.container&&this.options.showFrame){const e=this.options.frameWidth?this.options.frameWidth:c;this.container.style.borderTopWidth=e+"px",this.container.style.borderBottomWidth=e+"px"}const l=t*o-this._decoratingElementsHeight();this.container&&(this.container.style.top=a+"px",this.container.style.height=l+"px",this.container.style.overflow="hidden"),this._doLayout(l,n),this.options.keepEditorSelection||this.editor.setSelection(e);const h=this.editor.getModel();if(h){const t=h.validateRange(new _.Q(e.startLineNumber,1,e.endLineNumber+1,1));this.revealRange(t,t.startLineNumber===h.getLineCount())}}revealRange(e,t){t?this.editor.revealLineNearTop(e.endLineNumber,0):this.editor.revealRange(e,0)}setCssClass(e,t){this.container&&(t&&this.container.classList.remove(t),this.container.classList.add(e))}_onWidth(e){}_doLayout(e,t){}_relayout(e){this._viewZone&&this._viewZone.heightInLines!==e&&this.editor.changeViewZones((t=>{this._viewZone&&(this._viewZone.heightInLines=e,t.layoutZone(this._viewZone.id))}))}_initSash(){if(this._resizeSash)return;let e;this._resizeSash=this._disposables.add(new p.m(this.domNode,this,{orientation:1})),this.options.isResizeable||(this._resizeSash.state=0),this._disposables.add(this._resizeSash.onDidStart((t=>{this._viewZone&&(e={startY:t.startY,heightInLines:this._viewZone.heightInLines})}))),this._disposables.add(this._resizeSash.onDidEnd((()=>{e=void 0}))),this._disposables.add(this._resizeSash.onDidChange((t=>{if(e){const i=(t.currentY-e.startY)/this.editor.getOption(67),s=i<0?Math.ceil(i):Math.floor(i),n=e.heightInLines+s;n>5&&n<35&&this._relayout(n)}})))}getHorizontalSashLeft(){return 0}getHorizontalSashTop(){return(null===this.domNode.style.height?0:parseInt(this.domNode.style.height))-this._decoratingElementsHeight()/2}getHorizontalSashWidth(){const e=this.editor.getLayoutInfo();return e.width-e.minimap.minimapWidth}}var R=i(78209),L=i(57629),T=i(32848),x=i(14718),k=i(63591),A=i(66261),N=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},I=function(e,t){return function(i,s){t(i,s,e)}};const O=(0,k.u1)("IPeekViewService");var D;(0,x.v)(O,class{constructor(){this._widgets=new Map}addExclusiveWidget(e,t){const i=this._widgets.get(e);i&&(i.listener.dispose(),i.widget.dispose());this._widgets.set(e,{widget:t,listener:t.onDidClose((()=>{const i=this._widgets.get(e);i&&i.widget===t&&(i.listener.dispose(),this._widgets.delete(e))}))})}},1),function(e){e.inPeekEditor=new T.N1("inReferenceSearchEditor",!0,R.kg("inReferenceSearchEditor","Whether the current code editor is embedded inside peek")),e.notInPeekEditor=e.inPeekEditor.toNegated()}(D||(D={}));let M=class{static{this.ID="editor.contrib.referenceController"}constructor(e,t){e instanceof g.t&&D.inPeekEditor.bindTo(t)}dispose(){}};function P(e){const t=e.get(u.T).getFocusedCodeEditor();return t instanceof g.t?t.getParentEditor():t}M=N([I(1,T.fN)],M),(0,d.HW)(M.ID,M,0);const F={headerBackgroundColor:c.Q1.white,primaryHeadingColor:c.Q1.fromHex("#333333"),secondaryHeadingColor:c.Q1.fromHex("#6c6c6cb3")};let U=class extends w{constructor(e,t,i){super(e,t),this.instantiationService=i,this._onDidClose=new l.vl,this.onDidClose=this._onDidClose.event,h.co(this.options,F,!1)}dispose(){this.disposed||(this.disposed=!0,super.dispose(),this._onDidClose.fire(this))}style(e){const t=this.options;e.headerBackgroundColor&&(t.headerBackgroundColor=e.headerBackgroundColor),e.primaryHeadingColor&&(t.primaryHeadingColor=e.primaryHeadingColor),e.secondaryHeadingColor&&(t.secondaryHeadingColor=e.secondaryHeadingColor),super.style(e)}_applyStyles(){super._applyStyles();const e=this.options;this._headElement&&e.headerBackgroundColor&&(this._headElement.style.backgroundColor=e.headerBackgroundColor.toString()),this._primaryHeading&&e.primaryHeadingColor&&(this._primaryHeading.style.color=e.primaryHeadingColor.toString()),this._secondaryHeading&&e.secondaryHeadingColor&&(this._secondaryHeading.style.color=e.secondaryHeadingColor.toString()),this._bodyElement&&e.frameColor&&(this._bodyElement.style.borderColor=e.frameColor.toString())}_fillContainer(e){this.setCssClass("peekview-widget"),this._headElement=s.$(".head"),this._bodyElement=s.$(".body"),this._fillHead(this._headElement),this._fillBody(this._bodyElement),e.appendChild(this._headElement),e.appendChild(this._bodyElement)}_fillHead(e,t){this._titleElement=s.$(".peekview-title"),this.options.supportOnTitleClick&&(this._titleElement.classList.add("clickable"),s.b2(this._titleElement,"click",(e=>this._onTitleClick(e)))),s.BC(this._headElement,this._titleElement),this._fillTitleIcon(this._titleElement),this._primaryHeading=s.$("span.filename"),this._secondaryHeading=s.$("span.dirname"),this._metaHeading=s.$("span.meta"),s.BC(this._titleElement,this._primaryHeading,this._secondaryHeading,this._metaHeading);const i=s.$(".peekview-actions");s.BC(this._headElement,i);const c=this._getActionBarOptions();this._actionbarWidget=new n.E(i,c),this._disposables.add(this._actionbarWidget),t||this._actionbarWidget.push(new r.rc("peekview.close",R.kg("label.close","Close"),a.L.asClassName(o.W.close),!0,(()=>(this.dispose(),Promise.resolve()))),{label:!1,icon:!0})}_fillTitleIcon(e){}_getActionBarOptions(){return{actionViewItemProvider:L.rN.bind(void 0,this.instantiationService),orientation:0}}_onTitleClick(e){}setTitle(e,t){this._primaryHeading&&this._secondaryHeading&&(this._primaryHeading.innerText=e,this._primaryHeading.setAttribute("title",e),t?this._secondaryHeading.innerText=t:s.w_(this._secondaryHeading))}setMetaTitle(e){this._metaHeading&&(e?(this._metaHeading.innerText=e,s.WU(this._metaHeading)):s.jD(this._metaHeading))}_doLayout(e,t){if(!this._isShowing&&e<0)return void this.dispose();const i=Math.ceil(1.2*this.editor.getOption(67)),s=Math.round(e-(i+2));this._doLayoutHead(i,t),this._doLayoutBody(s,t)}_doLayoutHead(e,t){this._headElement&&(this._headElement.style.height=`${e}px`,this._headElement.style.lineHeight=this._headElement.style.height)}_doLayoutBody(e,t){this._bodyElement&&(this._bodyElement.style.height=`${e}px`)}};U=N([I(2,k._Y)],U);const H=(0,A.x1A)("peekViewTitle.background",{dark:"#252526",light:"#F3F3F3",hcDark:c.Q1.black,hcLight:c.Q1.white},R.kg("peekViewTitleBackground","Background color of the peek view title area.")),B=(0,A.x1A)("peekViewTitleLabel.foreground",{dark:c.Q1.white,light:c.Q1.black,hcDark:c.Q1.white,hcLight:A.By2},R.kg("peekViewTitleForeground","Color of the peek view title.")),W=(0,A.x1A)("peekViewTitleDescription.foreground",{dark:"#ccccccb3",light:"#616161",hcDark:"#FFFFFF99",hcLight:"#292929"},R.kg("peekViewTitleInfoForeground","Color of the peek view title info.")),V=(0,A.x1A)("peekView.border",{dark:A.pOz,light:A.pOz,hcDark:A.b1q,hcLight:A.b1q},R.kg("peekViewBorder","Color of the peek view borders and arrow.")),z=(0,A.x1A)("peekViewResult.background",{dark:"#252526",light:"#F3F3F3",hcDark:c.Q1.black,hcLight:c.Q1.white},R.kg("peekViewResultsBackground","Background color of the peek view result list.")),G=((0,A.x1A)("peekViewResult.lineForeground",{dark:"#bbbbbb",light:"#646465",hcDark:c.Q1.white,hcLight:A.By2},R.kg("peekViewResultsMatchForeground","Foreground color for line nodes in the peek view result list.")),(0,A.x1A)("peekViewResult.fileForeground",{dark:c.Q1.white,light:"#1E1E1E",hcDark:c.Q1.white,hcLight:A.By2},R.kg("peekViewResultsFileForeground","Foreground color for file nodes in the peek view result list.")),(0,A.x1A)("peekViewResult.selectionBackground",{dark:"#3399ff33",light:"#3399ff33",hcDark:null,hcLight:null},R.kg("peekViewResultsSelectionBackground","Background color of the selected entry in the peek view result list.")),(0,A.x1A)("peekViewResult.selectionForeground",{dark:c.Q1.white,light:"#6C6C6C",hcDark:c.Q1.white,hcLight:A.By2},R.kg("peekViewResultsSelectionForeground","Foreground color of the selected entry in the peek view result list.")),(0,A.x1A)("peekViewEditor.background",{dark:"#001F33",light:"#F2F8FC",hcDark:c.Q1.black,hcLight:c.Q1.white},R.kg("peekViewEditorBackground","Background color of the peek view editor.")));(0,A.x1A)("peekViewEditorGutter.background",G,R.kg("peekViewEditorGutterBackground","Background color of the gutter in the peek view editor.")),(0,A.x1A)("peekViewEditorStickyScroll.background",G,R.kg("peekViewEditorStickScrollBackground","Background color of sticky scroll in the peek view editor.")),(0,A.x1A)("peekViewResult.matchHighlightBackground",{dark:"#ea5c004d",light:"#ea5c004d",hcDark:null,hcLight:null},R.kg("peekViewResultsMatchHighlight","Match highlight color in the peek view result list.")),(0,A.x1A)("peekViewEditor.matchHighlightBackground",{dark:"#ff8f0099",light:"#f5d802de",hcDark:null,hcLight:null},R.kg("peekViewEditorMatchHighlight","Match highlight color in the peek view editor.")),(0,A.x1A)("peekViewEditor.matchHighlightBorder",{dark:null,light:null,hcDark:A.buw,hcLight:A.buw},R.kg("peekViewEditorMatchHighlightBorder","Match highlight border in the peek view editor."))},84316:e=>{e.exports=function(){function e(e){const t=864e5*Number(e.$value),i=new Date(t),s=i.getFullYear();return s<=0&&i.setFullYear(s-1),isNaN(i.valueOf())?"Invalid date":i.toISOString().split("T")[0]}return e.isScalar=!0,e}},84325:(e,t,i)=>{"use strict";var s,n=i(8597),r=i(47661),o=i(5662),a=i(31450),c=i(62083),l=i(25982),h=i(20788),d=i(10154),u=i(24520),g=i(51861),p=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},m=function(e,t){return function(i,s){t(i,s,e)}};let f=class extends o.jG{static{s=this}static{this.ID="editor.contrib.inspectTokens"}static get(e){return e.getContribution(s.ID)}constructor(e,t,i){super(),this._editor=e,this._languageService=i,this._widget=null,this._register(this._editor.onDidChangeModel((e=>this.stop()))),this._register(this._editor.onDidChangeModelLanguage((e=>this.stop()))),this._register(c.dG.onDidChange((e=>this.stop()))),this._register(this._editor.onKeyUp((e=>9===e.keyCode&&this.stop())))}dispose(){this.stop(),super.dispose()}launch(){this._widget||this._editor.hasModel()&&(this._widget=new v(this._editor,this._languageService))}stop(){this._widget&&(this._widget.dispose(),this._widget=null)}};f=s=p([m(1,u.L),m(2,d.L)],f);class _ extends a.ks{constructor(){super({id:"editor.action.inspectTokens",label:g.YN.inspectTokensAction,alias:"Developer: Inspect Tokens",precondition:void 0})}run(e,t){const i=f.get(t);i?.launch()}}class v extends o.jG{static{this._ID="editor.contrib.inspectTokensWidget"}constructor(e,t){super(),this.allowEditorOverflow=!0,this._editor=e,this._languageService=t,this._model=this._editor.getModel(),this._domNode=document.createElement("div"),this._domNode.className="tokens-inspect-widget",this._tokenizationSupport=function(e,t){const i=c.dG.get(t);if(i)return i;const s=e.encodeLanguageId(t);return{getInitialState:()=>h.r3,tokenize:(e,i,s)=>(0,h.$H)(t,s),tokenizeEncoded:(e,t,i)=>(0,h.Lh)(s,i)}}(this._languageService.languageIdCodec,this._model.getLanguageId()),this._compute(this._editor.getPosition()),this._register(this._editor.onDidChangeCursorPosition((e=>this._compute(this._editor.getPosition())))),this._editor.addContentWidget(this)}dispose(){this._editor.removeContentWidget(this),super.dispose()}getId(){return v._ID}_compute(e){const t=this._getTokensAtLine(e.lineNumber);let i=0;for(let n=t.tokens1.length-1;n>=0;n--){const s=t.tokens1[n];if(e.column-1>=s.offset){i=n;break}}let s=0;for(let n=t.tokens2.length>>>1;n>=0;n--)if(e.column-1>=t.tokens2[n<<1]){s=n;break}const o=this._model.getLineContent(e.lineNumber);let a="";if(i{"use strict";var s,n;i.d(t,{Lx:()=>n,Yo:()=>s,jh:()=>r,y2:()=>o}),function(e){e[e.Expanded=0]="Expanded",e[e.Collapsed=1]="Collapsed",e[e.PreserveOrExpanded=2]="PreserveOrExpanded",e[e.PreserveOrCollapsed=3]="PreserveOrCollapsed"}(s||(s={})),function(e){e[e.Unknown=0]="Unknown",e[e.Twistie=1]="Twistie",e[e.Element=2]="Element",e[e.Filter=3]="Filter"}(n||(n={}));class r extends Error{constructor(e,t){super(`TreeError [${e}] ${t}`)}}class o{constructor(e){this.fn=e,this._map=new WeakMap}map(e){let t=this._map.get(e);return t||(t=this.fn(e),this._map.set(e,t)),t}}},84585:(e,t,i)=>{"use strict";i.d(t,{K:()=>n,r:()=>s});const s="editor.semanticHighlighting";function n(e,t,i){const n=i.getValue(s,{overrideIdentifier:e.getLanguageId(),resource:e.uri})?.enabled;return"boolean"===typeof n?n:t.getColorTheme().semanticHighlighting}},84739:(e,t,i)=>{"use strict";var s;i.d(t,{N6:()=>s,TH:()=>n,pv:()=>r}),function(e){e[e.Disabled=0]="Disabled",e[e.EnabledForActive=1]="EnabledForActive",e[e.Enabled=2]="Enabled"}(s||(s={}));class n{constructor(e,t,i,s,n,r){if(this.visibleColumn=e,this.column=t,this.className=i,this.horizontalLine=s,this.forWrappedLinesAfterColumn=n,this.forWrappedLinesBeforeOrAtColumn=r,-1!==e===(-1!==t))throw new Error}}class r{constructor(e,t){this.top=e,this.endColumn=t}}},84840:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"ecl",extensions:[".ecl"],aliases:["ECL","Ecl","ecl"],loader:()=>i.e(734).then(i.bind(i,734))})},85117:(e,t,i)=>{"use strict";var s,n=i(25890),r=i(90766),o=i(18447),a=i(47661),c=i(64383),l=i(41234),h=i(5662),d=i(91508),u=i(79400),g=i(31450),p=i(80301),m=i(83069),f=i(36677),_=i(60002),v=i(87289),C=i(17469),E=i(78209),b=i(32848),S=i(56942),y=i(66261),w=i(32500),R=i(78381),L=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},T=function(e,t){return function(i,s){t(i,s,e)}};const x=new b.N1("LinkedEditingInputVisible",!1);let k=class extends h.jG{static{s=this}static{this.ID="editor.contrib.linkedEditing"}static{this.DECORATION=v.kI.register({description:"linked-editing",stickiness:0,className:"linked-editing-decoration"})}static get(e){return e.getContribution(s.ID)}constructor(e,t,i,s,n){super(),this.languageConfigurationService=s,this._syncRangesToken=0,this._localToDispose=this._register(new h.Cm),this._editor=e,this._providers=i.linkedEditingRangeProvider,this._enabled=!1,this._visibleContextKey=x.bindTo(t),this._debounceInformation=n.for(this._providers,"Linked Editing",{max:200}),this._currentDecorations=this._editor.createDecorationsCollection(),this._languageWordPattern=null,this._currentWordPattern=null,this._ignoreChangeEvent=!1,this._localToDispose=this._register(new h.Cm),this._rangeUpdateTriggerPromise=null,this._rangeSyncTriggerPromise=null,this._currentRequestCts=null,this._currentRequestPosition=null,this._currentRequestModelVersion=null,this._register(this._editor.onDidChangeModel((()=>this.reinitialize(!0)))),this._register(this._editor.onDidChangeConfiguration((e=>{(e.hasChanged(70)||e.hasChanged(94))&&this.reinitialize(!1)}))),this._register(this._providers.onDidChange((()=>this.reinitialize(!1)))),this._register(this._editor.onDidChangeModelLanguage((()=>this.reinitialize(!0)))),this.reinitialize(!0)}reinitialize(e){const t=this._editor.getModel(),i=null!==t&&(this._editor.getOption(70)||this._editor.getOption(94))&&this._providers.has(t);if(i===this._enabled&&!e)return;if(this._enabled=i,this.clearRanges(),this._localToDispose.clear(),!i||null===t)return;this._localToDispose.add(l.Jh.runAndSubscribe(t.onDidChangeLanguageConfiguration,(()=>{this._languageWordPattern=this.languageConfigurationService.getLanguageConfiguration(t.getLanguageId()).getWordDefinition()})));const s=new r.ve(this._debounceInformation.get(t)),n=()=>{this._rangeUpdateTriggerPromise=s.trigger((()=>this.updateRanges()),this._debounceDuration??this._debounceInformation.get(t))},o=new r.ve(0),a=e=>{this._rangeSyncTriggerPromise=o.trigger((()=>this._syncRanges(e)))};this._localToDispose.add(this._editor.onDidChangeCursorPosition((()=>{n()}))),this._localToDispose.add(this._editor.onDidChangeModelContent((e=>{if(!this._ignoreChangeEvent&&this._currentDecorations.length>0){const t=this._currentDecorations.getRange(0);if(t&&e.changes.every((e=>t.intersectRanges(e.range))))return void a(this._syncRangesToken)}n()}))),this._localToDispose.add({dispose:()=>{s.dispose(),o.dispose()}}),this.updateRanges()}_syncRanges(e){if(!this._editor.hasModel()||e!==this._syncRangesToken||0===this._currentDecorations.length)return;const t=this._editor.getModel(),i=this._currentDecorations.getRange(0);if(!i||i.startLineNumber!==i.endLineNumber)return this.clearRanges();const s=t.getValueInRange(i);if(this._currentWordPattern){const e=s.match(this._currentWordPattern);if((e?e[0].length:0)!==s.length)return this.clearRanges()}const n=[];for(let r=1,o=this._currentDecorations.length;r1)return void this.clearRanges();const i=this._editor.getModel(),n=i.getVersionId();if(this._currentRequestPosition&&this._currentRequestModelVersion===n){if(t.equals(this._currentRequestPosition))return;if(this._currentDecorations.length>0){const e=this._currentDecorations.getRange(0);if(e&&e.containsPosition(t))return}}this.clearRanges(),this._currentRequestPosition=t,this._currentRequestModelVersion=n;const r=this._currentRequestCts=new o.Qi;try{const e=new R.W(!1),o=await I(this._providers,i,t,r.token);if(this._debounceInformation.update(i,e.elapsed()),r!==this._currentRequestCts)return;if(this._currentRequestCts=null,n!==i.getVersionId())return;let a=[];o?.ranges&&(a=o.ranges),this._currentWordPattern=o?.wordPattern||this._languageWordPattern;let c=!1;for(let i=0,s=a.length;i({range:e,options:s.DECORATION})));this._visibleContextKey.set(!0),this._currentDecorations.set(l),this._syncRangesToken++}catch(a){(0,c.MB)(a)||(0,c.dz)(a),this._currentRequestCts!==r&&this._currentRequestCts||this.clearRanges()}}};k=s=L([T(1,b.fN),T(2,S.ILanguageFeaturesService),T(3,C.JZ),T(4,w.ILanguageFeatureDebounceService)],k);class A extends g.ks{constructor(){super({id:"editor.action.linkedEditing",label:E.kg("linkedEditing.label","Start Linked Editing"),alias:"Start Linked Editing",precondition:b.M$.and(_.R.writable,_.R.hasRenameProvider),kbOpts:{kbExpr:_.R.editorTextFocus,primary:3132,weight:100}})}runCommand(e,t){const i=e.get(p.T),[s,n]=Array.isArray(t)&&t||[void 0,void 0];return u.r.isUri(s)&&m.y.isIPosition(n)?i.openCodeEditor({resource:s},i.getActiveCodeEditor()).then((e=>{e&&(e.setPosition(n),e.invokeWithinContext((t=>(this.reportTelemetry(t,e),this.run(t,e)))))}),c.dz):super.runCommand(e,t)}run(e,t){const i=k.get(t);return i?Promise.resolve(i.updateRanges(!0)):Promise.resolve()}}const N=g.DX.bindToContribution(k.get);function I(e,t,i,s){const o=e.ordered(t);return(0,r.$1)(o.map((e=>async()=>{try{return await e.provideLinkedEditingRanges(t,i,s)}catch(n){return void(0,c.M_)(n)}})),(e=>!!e&&n.EI(e?.ranges)))}(0,g.E_)(new N({id:"cancelLinkedEditingInput",precondition:x,handler:e=>e.clearRanges(),kbOpts:{kbExpr:_.R.editorTextFocus,weight:199,primary:9,secondary:[1033]}}));(0,y.x1A)("editor.linkedEditingBackground",{dark:a.Q1.fromHex("#f00").transparent(.3),light:a.Q1.fromHex("#f00").transparent(.3),hcDark:a.Q1.fromHex("#f00").transparent(.3),hcLight:a.Q1.white},E.kg("editorLinkedEditingBackground","Background color when the editor auto renames on type."));(0,g.ke)("_executeLinkedEditingProvider",((e,t,i)=>{const{linkedEditingRangeProvider:s}=e.get(S.ILanguageFeaturesService);return I(s,t,i,o.XO.None)})),(0,g.HW)(k.ID,k,1),(0,g.Fl)(A)},85152:(e,t,i)=>{"use strict";function s(e){return e<0?0:e>255?255:0|e}function n(e){return e<0?0:e>4294967295?4294967295:0|e}i.d(t,{W:()=>s,j:()=>n})},85283:(e,t,i)=>{"use strict";i.d(t,{A:()=>o});var s,n=i(59284);function r(){return r=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{l:()=>d,q:()=>c});var s=i(42731),n=i(17799),r=i(44320),o=i(79400),a=i(61292);function c(e){const t=new n.Vq;for(const i of e.items){const e=i.type;if("string"===i.kind){const s=new Promise((e=>i.getAsString(e)));t.append(e,(0,n.gf)(s))}else if("file"===i.kind){const s=i.getAsFile();s&&t.append(e,l(s))}}return t}function l(e){const t=e.path?o.r.parse(e.path):void 0;return(0,n.VX)(e.name,t,(async()=>new Uint8Array(await e.arrayBuffer())))}const h=Object.freeze([a.sV.EDITORS,a.sV.FILES,s.t.RESOURCES,s.t.INTERNAL_URI_LIST]);function d(e,t=!1){const i=c(e),a=i.get(s.t.INTERNAL_URI_LIST);if(a)i.replace(r.K.uriList,a);else if(t||!i.has(r.K.uriList)){const t=[];for(const i of e.items){const e=i.getAsFile();if(e){const i=e.path;try{i?t.push(o.r.file(i).toString()):t.push(o.r.parse(e.name,!0).toString())}catch{}}}t.length&&i.replace(r.K.uriList,(0,n.gf)(n.jt.create(t)))}for(const s of h)i.delete(s);return i}},85541:(e,t,i)=>{"use strict";i.d(t,{H:()=>o,v:()=>r});var s=i(80537),n=i(29319);function r(e,t,i){return("string"===typeof i.insertText?""===i.insertText:""===i.insertText.snippet)?{edits:i.additionalEdit?.edits??[]}:{edits:[...t.map((t=>new s.cw(e,{range:t,text:"string"===typeof i.insertText?n.fr.escape(i.insertText)+"$0":i.insertText.snippet,insertAsSnippet:!0}))),...i.additionalEdit?.edits??[]]}}function o(e){function t(e,t){return"mimeType"in e?e.mimeType===t.handledMimeType:!!t.kind&&e.kind.contains(t.kind)}const i=new Map;for(const r of e)for(const s of r.yieldTo??[])for(const n of e)if(n!==r&&t(s,n)){let e=i.get(r);e||(e=[],i.set(r,e)),e.push(n)}if(!i.size)return Array.from(e);const s=new Set,n=[];return function e(t){if(!t.length)return[];const r=t[0];if(n.includes(r))return console.warn("Yield to cycle detected",r),t;if(s.has(r))return e(t.slice(1));let o=[];const a=i.get(r);return a&&(n.push(r),o=e(a),n.pop()),s.add(r),[...o,r,...e(t.slice(1))]}(Array.from(e))}},85600:(e,t,i)=>{"use strict";i.d(t,{e2:()=>a,sN:()=>r,tW:()=>n,v7:()=>d});var s=i(91508);function n(e){return r(e,0)}function r(e,t){switch(typeof e){case"object":return null===e?o(349,t):Array.isArray(e)?(i=e,s=o(104579,s=t),i.reduce(((e,t)=>r(t,e)),s)):function(e,t){return t=o(181387,t),Object.keys(e).sort().reduce(((t,i)=>(t=a(i,t),r(e[i],t))),t)}(e,t);case"string":return a(e,t);case"boolean":return function(e,t){return o(e?433:863,t)}(e,t);case"number":return o(e,t);case"undefined":return o(937,t);default:return o(617,t)}var i,s}function o(e,t){return(t<<5)-t+e|0}function a(e,t){t=o(149417,t);for(let i=0,s=e.length;i>>s)>>>0}function l(e,t=0,i=e.byteLength,s=0){for(let n=0;ne.toString(16).padStart(2,"0"))).join(""):function(e,t,i="0"){for(;e.length>>0).toString(16),t/4)}class d{static{this._bigBlock32=new DataView(new ArrayBuffer(320))}constructor(){this._h0=1732584193,this._h1=4023233417,this._h2=2562383102,this._h3=271733878,this._h4=3285377520,this._buff=new Uint8Array(67),this._buffDV=new DataView(this._buff.buffer),this._buffLen=0,this._totalLen=0,this._leftoverHighSurrogate=0,this._finished=!1}update(e){const t=e.length;if(0===t)return;const i=this._buff;let n,r,o=this._buffLen,a=this._leftoverHighSurrogate;for(0!==a?(n=a,r=-1,a=0):(n=e.charCodeAt(0),r=0);;){let c=n;if(s.pc(n)){if(!(r+1>>6,e[t++]=128|(63&i)>>>0):i<65536?(e[t++]=224|(61440&i)>>>12,e[t++]=128|(4032&i)>>>6,e[t++]=128|(63&i)>>>0):(e[t++]=240|(1835008&i)>>>18,e[t++]=128|(258048&i)>>>12,e[t++]=128|(4032&i)>>>6,e[t++]=128|(63&i)>>>0),t>=64&&(this._step(),t-=64,this._totalLen+=64,e[0]=e[64],e[1]=e[65],e[2]=e[66]),t}digest(){return this._finished||(this._finished=!0,this._leftoverHighSurrogate&&(this._leftoverHighSurrogate=0,this._buffLen=this._push(this._buff,this._buffLen,65533)),this._totalLen+=this._buffLen,this._wrapUp()),h(this._h0)+h(this._h1)+h(this._h2)+h(this._h3)+h(this._h4)}_wrapUp(){this._buff[this._buffLen++]=128,l(this._buff,this._buffLen),this._buffLen>56&&(this._step(),l(this._buff));const e=8*this._totalLen;this._buffDV.setUint32(56,Math.floor(e/4294967296),!1),this._buffDV.setUint32(60,e%4294967296,!1),this._step()}_step(){const e=d._bigBlock32,t=this._buffDV;for(let c=0;c<64;c+=4)e.setUint32(c,t.getUint32(c,!1),!1);for(let d=64;d<320;d+=4)e.setUint32(d,c(e.getUint32(d-12,!1)^e.getUint32(d-32,!1)^e.getUint32(d-56,!1)^e.getUint32(d-64,!1),1),!1);let i,s,n,r=this._h0,o=this._h1,a=this._h2,l=this._h3,h=this._h4;for(let d=0;d<80;d++)d<20?(i=o&a|~o&l,s=1518500249):d<40?(i=o^a^l,s=1859775393):d<60?(i=o&a|o&l|a&l,s=2400959708):(i=o^a^l,s=3395469782),n=c(r,5)+i+h+s+e.getUint32(4*d,!1)&4294967295,h=l,l=a,a=c(o,30),o=r,r=n;this._h0=this._h0+r&4294967295,this._h1=this._h1+o&4294967295,this._h2=this._h2+a&4294967295,this._h3=this._h3+l&4294967295,this._h4=this._h4+h&4294967295}}},85646:(e,t,i)=>{"use strict";var s=i(31450),n=i(87119),r=i(78209),o=i(83844),a=i(1098),c=i(30076),l=i(41127),h=i(31308),d=i(63591),u=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};class p{constructor(e){this.instantiationService=e}init(...e){}}let m=class extends p{constructor(e,t){super(t),this.init(e)}};var f;m=u([g(1,d._Y)],m),(0,s.HW)(a.X.ID,(f=()=>a.X,(0,c.e)()?function(e,t){return class extends t{constructor(){super(...arguments),this._autorun=void 0}init(...t){this._autorun=(0,h.yC)(((i,s)=>{const n=(0,l.b)(e(),i);s.add(this.instantiationService.createInstance(n,...t))}))}dispose(){this._autorun?.dispose()}}}(f,m):f()),0),(0,o.x1)("editor.placeholder.foreground",n.Ek,(0,r.kg)("placeholderForeground","Foreground color of the placeholder text in the editor."))},85858:e=>{!function(){"use strict";const t=function(e){if(void 0===e)return"undefined";if(null===e)return"null";if(e&&(1===e.nodeType||9===e.nodeType))return"element";const t=Object.prototype.toString.call(e),i=t.substring(8,t.length-1).toLowerCase();if("number"===i){if(isNaN(e))return"nan";if(!isFinite(e))return"infinity"}return i},i=["Null","Undefined","Object","Array","String","Number","Boolean","Function","RegExp","Element","NaN","Infinite","Symbol"],s=function(e){t["is"+e]=function(i){return t(i)===e.toLowerCase()}};for(let e=0;e{"use strict";(0,i(34918).K)({id:"typescript",extensions:[".ts",".tsx",".cts",".mts"],aliases:["TypeScript","ts","typescript"],mimetypes:["text/typescript"],loader:()=>i.e(1606).then(i.bind(i,1606))})},86492:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"lua",extensions:[".lua"],aliases:["Lua","lua"],loader:()=>i.e(95050).then(i.bind(i,95050))})},86571:(e,t,i)=>{"use strict";i.d(t,{M:()=>a,S:()=>c});var s=i(64383),n=i(74444),r=i(36677),o=i(46041);class a{static fromRangeInclusive(e){return new a(e.startLineNumber,e.endLineNumber+1)}static joinMany(e){if(0===e.length)return[];let t=new c(e[0].slice());for(let i=1;it)throw new s.D7(`startLineNumber ${e} cannot be after endLineNumberExclusive ${t}`);this.startLineNumber=e,this.endLineNumberExclusive=t}contains(e){return this.startLineNumber<=e&&et.endLineNumberExclusive>=e.startLineNumber)),i=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===i)this._normalizedRanges.splice(t,0,e);else if(t===i-1){const i=this._normalizedRanges[t];this._normalizedRanges[t]=i.join(e)}else{const s=this._normalizedRanges[t].join(this._normalizedRanges[i-1]).join(e);this._normalizedRanges.splice(t,i-t,s)}}contains(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumber<=e));return!!t&&t.endLineNumberExclusive>e}intersects(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumbere.startLineNumber}getUnion(e){if(0===this._normalizedRanges.length)return e;if(0===e._normalizedRanges.length)return this;const t=[];let i=0,s=0,n=null;for(;i=r.startLineNumber?n=new a(n.startLineNumber,Math.max(n.endLineNumberExclusive,r.endLineNumberExclusive)):(t.push(n),n=r)}return null!==n&&t.push(n),new c(t)}subtractFrom(e){const t=(0,o.hw)(this._normalizedRanges,(t=>t.endLineNumberExclusive>=e.startLineNumber)),i=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===i)return new c([e]);const s=[];let n=e.startLineNumber;for(let r=t;rn&&s.push(new a(n,e.startLineNumber)),n=e.endLineNumberExclusive}return ne.toString())).join(", ")}getIntersection(e){const t=[];let i=0,s=0;for(;it.delta(e))))}}},86723:(e,t,i)=>{"use strict";var s;function n(e){return e===s.HIGH_CONTRAST_DARK||e===s.HIGH_CONTRAST_LIGHT}function r(e){return e===s.DARK||e===s.HIGH_CONTRAST_DARK}i.d(t,{Bb:()=>n,HD:()=>r,zM:()=>s}),function(e){e.DARK="dark",e.LIGHT="light",e.HIGH_CONTRAST_DARK="hcDark",e.HIGH_CONTRAST_LIGHT="hcLight"}(s||(s={}))},87119:(e,t,i)=>{"use strict";i.d(t,{A3:()=>x,AQ:()=>W,Am:()=>L,As:()=>A,BD:()=>J,Bo:()=>X,CM:()=>w,D0:()=>l,Ek:()=>P,H0:()=>R,I2:()=>Q,IW:()=>ee,If:()=>Z,JB:()=>I,L0:()=>p,Mf:()=>c,P1:()=>re,Pe:()=>se,Qt:()=>f,WD:()=>ne,WS:()=>ie,WY:()=>oe,Xr:()=>D,aZ:()=>B,bB:()=>te,hz:()=>b,je:()=>u,kG:()=>a,kM:()=>h,l5:()=>j,lQ:()=>z,n4:()=>$,ob:()=>E,ow:()=>S,s7:()=>q,sC:()=>d,sH:()=>K,sN:()=>V,ss:()=>G,tK:()=>T,tp:()=>k,vP:()=>y,vV:()=>C,vp:()=>U,w4:()=>m,we:()=>g,x9:()=>O,yI:()=>H,yw:()=>M,zp:()=>Y});var s=i(78209),n=i(47661),r=i(66261),o=i(47612);const a=(0,r.x1A)("editor.lineHighlightBackground",null,s.kg("lineHighlight","Background color for the highlight of line at the cursor position.")),c=(0,r.x1A)("editor.lineHighlightBorder",{dark:"#282828",light:"#eeeeee",hcDark:"#f38518",hcLight:r.b1q},s.kg("lineHighlightBorderBox","Background color for the border around the line at the cursor position.")),l=((0,r.x1A)("editor.rangeHighlightBackground",{dark:"#ffffff0b",light:"#fdff0033",hcDark:null,hcLight:null},s.kg("rangeHighlight","Background color of highlighted ranges, like by quick open and find features. The color must not be opaque so as not to hide underlying decorations."),!0),(0,r.x1A)("editor.rangeHighlightBorder",{dark:null,light:null,hcDark:r.buw,hcLight:r.buw},s.kg("rangeHighlightBorder","Background color of the border around highlighted ranges.")),(0,r.x1A)("editor.symbolHighlightBackground",{dark:r.Ubg,light:r.Ubg,hcDark:null,hcLight:null},s.kg("symbolHighlight","Background color of highlighted symbol, like for go to definition or go next/previous symbol. The color must not be opaque so as not to hide underlying decorations."),!0),(0,r.x1A)("editor.symbolHighlightBorder",{dark:null,light:null,hcDark:r.buw,hcLight:r.buw},s.kg("symbolHighlightBorder","Background color of the border around highlighted symbols.")),(0,r.x1A)("editorCursor.foreground",{dark:"#AEAFAD",light:n.Q1.black,hcDark:n.Q1.white,hcLight:"#0F4A85"},s.kg("caret","Color of the editor cursor."))),h=(0,r.x1A)("editorCursor.background",null,s.kg("editorCursorBackground","The background color of the editor cursor. Allows customizing the color of a character overlapped by a block cursor.")),d=(0,r.x1A)("editorMultiCursor.primary.foreground",l,s.kg("editorMultiCursorPrimaryForeground","Color of the primary editor cursor when multiple cursors are present.")),u=(0,r.x1A)("editorMultiCursor.primary.background",h,s.kg("editorMultiCursorPrimaryBackground","The background color of the primary editor cursor when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),g=(0,r.x1A)("editorMultiCursor.secondary.foreground",l,s.kg("editorMultiCursorSecondaryForeground","Color of secondary editor cursors when multiple cursors are present.")),p=(0,r.x1A)("editorMultiCursor.secondary.background",h,s.kg("editorMultiCursorSecondaryBackground","The background color of secondary editor cursors when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),m=(0,r.x1A)("editorWhitespace.foreground",{dark:"#e3e4e229",light:"#33333333",hcDark:"#e3e4e229",hcLight:"#CCCCCC"},s.kg("editorWhitespaces","Color of whitespace characters in the editor.")),f=(0,r.x1A)("editorLineNumber.foreground",{dark:"#858585",light:"#237893",hcDark:n.Q1.white,hcLight:"#292929"},s.kg("editorLineNumbers","Color of editor line numbers.")),_=(0,r.x1A)("editorIndentGuide.background",m,s.kg("editorIndentGuides","Color of the editor indentation guides."),!1,s.kg("deprecatedEditorIndentGuides","'editorIndentGuide.background' is deprecated. Use 'editorIndentGuide.background1' instead.")),v=(0,r.x1A)("editorIndentGuide.activeBackground",m,s.kg("editorActiveIndentGuide","Color of the active editor indentation guides."),!1,s.kg("deprecatedEditorActiveIndentGuide","'editorIndentGuide.activeBackground' is deprecated. Use 'editorIndentGuide.activeBackground1' instead.")),C=(0,r.x1A)("editorIndentGuide.background1",_,s.kg("editorIndentGuides1","Color of the editor indentation guides (1).")),E=(0,r.x1A)("editorIndentGuide.background2","#00000000",s.kg("editorIndentGuides2","Color of the editor indentation guides (2).")),b=(0,r.x1A)("editorIndentGuide.background3","#00000000",s.kg("editorIndentGuides3","Color of the editor indentation guides (3).")),S=(0,r.x1A)("editorIndentGuide.background4","#00000000",s.kg("editorIndentGuides4","Color of the editor indentation guides (4).")),y=(0,r.x1A)("editorIndentGuide.background5","#00000000",s.kg("editorIndentGuides5","Color of the editor indentation guides (5).")),w=(0,r.x1A)("editorIndentGuide.background6","#00000000",s.kg("editorIndentGuides6","Color of the editor indentation guides (6).")),R=(0,r.x1A)("editorIndentGuide.activeBackground1",v,s.kg("editorActiveIndentGuide1","Color of the active editor indentation guides (1).")),L=(0,r.x1A)("editorIndentGuide.activeBackground2","#00000000",s.kg("editorActiveIndentGuide2","Color of the active editor indentation guides (2).")),T=(0,r.x1A)("editorIndentGuide.activeBackground3","#00000000",s.kg("editorActiveIndentGuide3","Color of the active editor indentation guides (3).")),x=(0,r.x1A)("editorIndentGuide.activeBackground4","#00000000",s.kg("editorActiveIndentGuide4","Color of the active editor indentation guides (4).")),k=(0,r.x1A)("editorIndentGuide.activeBackground5","#00000000",s.kg("editorActiveIndentGuide5","Color of the active editor indentation guides (5).")),A=(0,r.x1A)("editorIndentGuide.activeBackground6","#00000000",s.kg("editorActiveIndentGuide6","Color of the active editor indentation guides (6).")),N=(0,r.x1A)("editorActiveLineNumber.foreground",{dark:"#c6c6c6",light:"#0B216F",hcDark:r.buw,hcLight:r.buw},s.kg("editorActiveLineNumber","Color of editor active line number"),!1,s.kg("deprecatedEditorActiveLineNumber","Id is deprecated. Use 'editorLineNumber.activeForeground' instead.")),I=((0,r.x1A)("editorLineNumber.activeForeground",N,s.kg("editorActiveLineNumber","Color of editor active line number")),(0,r.x1A)("editorLineNumber.dimmedForeground",null,s.kg("editorDimmedLineNumber","Color of the final editor line when editor.renderFinalNewline is set to dimmed."))),O=((0,r.x1A)("editorRuler.foreground",{dark:"#5A5A5A",light:n.Q1.lightgrey,hcDark:n.Q1.white,hcLight:"#292929"},s.kg("editorRuler","Color of the editor rulers.")),(0,r.x1A)("editorCodeLens.foreground",{dark:"#999999",light:"#919191",hcDark:"#999999",hcLight:"#292929"},s.kg("editorCodeLensForeground","Foreground color of editor CodeLens")),(0,r.x1A)("editorBracketMatch.background",{dark:"#0064001a",light:"#0064001a",hcDark:"#0064001a",hcLight:"#0000"},s.kg("editorBracketMatchBackground","Background color behind matching brackets")),(0,r.x1A)("editorBracketMatch.border",{dark:"#888",light:"#B9B9B9",hcDark:r.b1q,hcLight:r.b1q},s.kg("editorBracketMatchBorder","Color for matching brackets boxes")),(0,r.x1A)("editorOverviewRuler.border",{dark:"#7f7f7f4d",light:"#7f7f7f4d",hcDark:"#7f7f7f4d",hcLight:"#666666"},s.kg("editorOverviewRulerBorder","Color of the overview ruler border."))),D=(0,r.x1A)("editorOverviewRuler.background",null,s.kg("editorOverviewRulerBackground","Background color of the editor overview ruler.")),M=((0,r.x1A)("editorGutter.background",r.YtV,s.kg("editorGutter","Background color of the editor gutter. The gutter contains the glyph margins and the line numbers.")),(0,r.x1A)("editorUnnecessaryCode.border",{dark:null,light:null,hcDark:n.Q1.fromHex("#fff").transparent(.8),hcLight:r.b1q},s.kg("unnecessaryCodeBorder","Border color of unnecessary (unused) source code in the editor.")),(0,r.x1A)("editorUnnecessaryCode.opacity",{dark:n.Q1.fromHex("#000a"),light:n.Q1.fromHex("#0007"),hcDark:null,hcLight:null},s.kg("unnecessaryCodeOpacity","Opacity of unnecessary (unused) source code in the editor. For example, \"#000000c0\" will render the code with 75% opacity. For high contrast themes, use the 'editorUnnecessaryCode.border' theme color to underline unnecessary code instead of fading it out."))),P=((0,r.x1A)("editorGhostText.border",{dark:null,light:null,hcDark:n.Q1.fromHex("#fff").transparent(.8),hcLight:n.Q1.fromHex("#292929").transparent(.8)},s.kg("editorGhostTextBorder","Border color of ghost text in the editor.")),(0,r.x1A)("editorGhostText.foreground",{dark:n.Q1.fromHex("#ffffff56"),light:n.Q1.fromHex("#0007"),hcDark:null,hcLight:null},s.kg("editorGhostTextForeground","Foreground color of the ghost text in the editor."))),F=((0,r.x1A)("editorGhostText.background",null,s.kg("editorGhostTextBackground","Background color of the ghost text in the editor.")),new n.Q1(new n.bU(0,122,204,.6))),U=(0,r.x1A)("editorOverviewRuler.rangeHighlightForeground",F,s.kg("overviewRulerRangeHighlight","Overview ruler marker color for range highlights. The color must not be opaque so as not to hide underlying decorations."),!0),H=(0,r.x1A)("editorOverviewRuler.errorForeground",{dark:new n.Q1(new n.bU(255,18,18,.7)),light:new n.Q1(new n.bU(255,18,18,.7)),hcDark:new n.Q1(new n.bU(255,50,50,1)),hcLight:"#B5200D"},s.kg("overviewRuleError","Overview ruler marker color for errors.")),B=(0,r.x1A)("editorOverviewRuler.warningForeground",{dark:r.Hng,light:r.Hng,hcDark:r.Stt,hcLight:r.Stt},s.kg("overviewRuleWarning","Overview ruler marker color for warnings.")),W=(0,r.x1A)("editorOverviewRuler.infoForeground",{dark:r.pOz,light:r.pOz,hcDark:r.IIb,hcLight:r.IIb},s.kg("overviewRuleInfo","Overview ruler marker color for infos.")),V=(0,r.x1A)("editorBracketHighlight.foreground1",{dark:"#FFD700",light:"#0431FAFF",hcDark:"#FFD700",hcLight:"#0431FAFF"},s.kg("editorBracketHighlightForeground1","Foreground color of brackets (1). Requires enabling bracket pair colorization.")),z=(0,r.x1A)("editorBracketHighlight.foreground2",{dark:"#DA70D6",light:"#319331FF",hcDark:"#DA70D6",hcLight:"#319331FF"},s.kg("editorBracketHighlightForeground2","Foreground color of brackets (2). Requires enabling bracket pair colorization.")),G=(0,r.x1A)("editorBracketHighlight.foreground3",{dark:"#179FFF",light:"#7B3814FF",hcDark:"#87CEFA",hcLight:"#7B3814FF"},s.kg("editorBracketHighlightForeground3","Foreground color of brackets (3). Requires enabling bracket pair colorization.")),j=(0,r.x1A)("editorBracketHighlight.foreground4","#00000000",s.kg("editorBracketHighlightForeground4","Foreground color of brackets (4). Requires enabling bracket pair colorization.")),K=(0,r.x1A)("editorBracketHighlight.foreground5","#00000000",s.kg("editorBracketHighlightForeground5","Foreground color of brackets (5). Requires enabling bracket pair colorization.")),Y=(0,r.x1A)("editorBracketHighlight.foreground6","#00000000",s.kg("editorBracketHighlightForeground6","Foreground color of brackets (6). Requires enabling bracket pair colorization.")),q=(0,r.x1A)("editorBracketHighlight.unexpectedBracket.foreground",{dark:new n.Q1(new n.bU(255,18,18,.8)),light:new n.Q1(new n.bU(255,18,18,.8)),hcDark:"new Color(new RGBA(255, 50, 50, 1))",hcLight:"#B5200D"},s.kg("editorBracketHighlightUnexpectedBracketForeground","Foreground color of unexpected brackets.")),$=(0,r.x1A)("editorBracketPairGuide.background1","#00000000",s.kg("editorBracketPairGuide.background1","Background color of inactive bracket pair guides (1). Requires enabling bracket pair guides.")),Q=(0,r.x1A)("editorBracketPairGuide.background2","#00000000",s.kg("editorBracketPairGuide.background2","Background color of inactive bracket pair guides (2). Requires enabling bracket pair guides.")),X=(0,r.x1A)("editorBracketPairGuide.background3","#00000000",s.kg("editorBracketPairGuide.background3","Background color of inactive bracket pair guides (3). Requires enabling bracket pair guides.")),Z=(0,r.x1A)("editorBracketPairGuide.background4","#00000000",s.kg("editorBracketPairGuide.background4","Background color of inactive bracket pair guides (4). Requires enabling bracket pair guides.")),J=(0,r.x1A)("editorBracketPairGuide.background5","#00000000",s.kg("editorBracketPairGuide.background5","Background color of inactive bracket pair guides (5). Requires enabling bracket pair guides.")),ee=(0,r.x1A)("editorBracketPairGuide.background6","#00000000",s.kg("editorBracketPairGuide.background6","Background color of inactive bracket pair guides (6). Requires enabling bracket pair guides.")),te=(0,r.x1A)("editorBracketPairGuide.activeBackground1","#00000000",s.kg("editorBracketPairGuide.activeBackground1","Background color of active bracket pair guides (1). Requires enabling bracket pair guides.")),ie=(0,r.x1A)("editorBracketPairGuide.activeBackground2","#00000000",s.kg("editorBracketPairGuide.activeBackground2","Background color of active bracket pair guides (2). Requires enabling bracket pair guides.")),se=(0,r.x1A)("editorBracketPairGuide.activeBackground3","#00000000",s.kg("editorBracketPairGuide.activeBackground3","Background color of active bracket pair guides (3). Requires enabling bracket pair guides.")),ne=(0,r.x1A)("editorBracketPairGuide.activeBackground4","#00000000",s.kg("editorBracketPairGuide.activeBackground4","Background color of active bracket pair guides (4). Requires enabling bracket pair guides.")),re=(0,r.x1A)("editorBracketPairGuide.activeBackground5","#00000000",s.kg("editorBracketPairGuide.activeBackground5","Background color of active bracket pair guides (5). Requires enabling bracket pair guides.")),oe=(0,r.x1A)("editorBracketPairGuide.activeBackground6","#00000000",s.kg("editorBracketPairGuide.activeBackground6","Background color of active bracket pair guides (6). Requires enabling bracket pair guides."));(0,r.x1A)("editorUnicodeHighlight.border",r.Hng,s.kg("editorUnicodeHighlight.border","Border color used to highlight unicode characters.")),(0,r.x1A)("editorUnicodeHighlight.background",r.whs,s.kg("editorUnicodeHighlight.background","Background color used to highlight unicode characters."));(0,o.zy)(((e,t)=>{const i=e.getColor(r.YtV),s=e.getColor(a),n=s&&!s.isTransparent()?s:i;n&&t.addRule(`.monaco-editor .inputarea.ime-input { background-color: ${n}; }`)}))},87152:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"css",extensions:[".css"],aliases:["CSS","css"],mimetypes:["text/css"],loader:()=>i.e(32742).then(i.bind(i,32742))})},87213:(e,t,i)=>{"use strict";i.d(t,{Nt:()=>n,Rh:()=>a});var s=i(78209);const n=(0,i(63591).u1)("accessibilitySignalService");Symbol("AcknowledgeDocCommentsToken");class r{static register(e){return new r(e.fileName)}static{this.error=r.register({fileName:"error.mp3"})}static{this.warning=r.register({fileName:"warning.mp3"})}static{this.success=r.register({fileName:"success.mp3"})}static{this.foldedArea=r.register({fileName:"foldedAreas.mp3"})}static{this.break=r.register({fileName:"break.mp3"})}static{this.quickFixes=r.register({fileName:"quickFixes.mp3"})}static{this.taskCompleted=r.register({fileName:"taskCompleted.mp3"})}static{this.taskFailed=r.register({fileName:"taskFailed.mp3"})}static{this.terminalBell=r.register({fileName:"terminalBell.mp3"})}static{this.diffLineInserted=r.register({fileName:"diffLineInserted.mp3"})}static{this.diffLineDeleted=r.register({fileName:"diffLineDeleted.mp3"})}static{this.diffLineModified=r.register({fileName:"diffLineModified.mp3"})}static{this.chatRequestSent=r.register({fileName:"chatRequestSent.mp3"})}static{this.chatResponseReceived1=r.register({fileName:"chatResponseReceived1.mp3"})}static{this.chatResponseReceived2=r.register({fileName:"chatResponseReceived2.mp3"})}static{this.chatResponseReceived3=r.register({fileName:"chatResponseReceived3.mp3"})}static{this.chatResponseReceived4=r.register({fileName:"chatResponseReceived4.mp3"})}static{this.clear=r.register({fileName:"clear.mp3"})}static{this.save=r.register({fileName:"save.mp3"})}static{this.format=r.register({fileName:"format.mp3"})}static{this.voiceRecordingStarted=r.register({fileName:"voiceRecordingStarted.mp3"})}static{this.voiceRecordingStopped=r.register({fileName:"voiceRecordingStopped.mp3"})}static{this.progress=r.register({fileName:"progress.mp3"})}constructor(e){this.fileName=e}}class o{constructor(e){this.randomOneOf=e}}class a{constructor(e,t,i,s,n,r){this.sound=e,this.name=t,this.legacySoundSettingsKey=i,this.settingsKey=s,this.legacyAnnouncementSettingsKey=n,this.announcementMessage=r}static{this._signals=new Set}static register(e){const t=new o("randomOneOf"in e.sound?e.sound.randomOneOf:[e.sound]),i=new a(t,e.name,e.legacySoundSettingsKey,e.settingsKey,e.legacyAnnouncementSettingsKey,e.announcementMessage);return a._signals.add(i),i}static{this.errorAtPosition=a.register({name:(0,s.kg)("accessibilitySignals.positionHasError.name","Error at Position"),sound:r.error,announcementMessage:(0,s.kg)("accessibility.signals.positionHasError","Error"),settingsKey:"accessibility.signals.positionHasError",delaySettingsKey:"accessibility.signalOptions.delays.errorAtPosition"})}static{this.warningAtPosition=a.register({name:(0,s.kg)("accessibilitySignals.positionHasWarning.name","Warning at Position"),sound:r.warning,announcementMessage:(0,s.kg)("accessibility.signals.positionHasWarning","Warning"),settingsKey:"accessibility.signals.positionHasWarning",delaySettingsKey:"accessibility.signalOptions.delays.warningAtPosition"})}static{this.errorOnLine=a.register({name:(0,s.kg)("accessibilitySignals.lineHasError.name","Error on Line"),sound:r.error,legacySoundSettingsKey:"audioCues.lineHasError",legacyAnnouncementSettingsKey:"accessibility.alert.error",announcementMessage:(0,s.kg)("accessibility.signals.lineHasError","Error on Line"),settingsKey:"accessibility.signals.lineHasError"})}static{this.warningOnLine=a.register({name:(0,s.kg)("accessibilitySignals.lineHasWarning.name","Warning on Line"),sound:r.warning,legacySoundSettingsKey:"audioCues.lineHasWarning",legacyAnnouncementSettingsKey:"accessibility.alert.warning",announcementMessage:(0,s.kg)("accessibility.signals.lineHasWarning","Warning on Line"),settingsKey:"accessibility.signals.lineHasWarning"})}static{this.foldedArea=a.register({name:(0,s.kg)("accessibilitySignals.lineHasFoldedArea.name","Folded Area on Line"),sound:r.foldedArea,legacySoundSettingsKey:"audioCues.lineHasFoldedArea",legacyAnnouncementSettingsKey:"accessibility.alert.foldedArea",announcementMessage:(0,s.kg)("accessibility.signals.lineHasFoldedArea","Folded"),settingsKey:"accessibility.signals.lineHasFoldedArea"})}static{this.break=a.register({name:(0,s.kg)("accessibilitySignals.lineHasBreakpoint.name","Breakpoint on Line"),sound:r.break,legacySoundSettingsKey:"audioCues.lineHasBreakpoint",legacyAnnouncementSettingsKey:"accessibility.alert.breakpoint",announcementMessage:(0,s.kg)("accessibility.signals.lineHasBreakpoint","Breakpoint"),settingsKey:"accessibility.signals.lineHasBreakpoint"})}static{this.inlineSuggestion=a.register({name:(0,s.kg)("accessibilitySignals.lineHasInlineSuggestion.name","Inline Suggestion on Line"),sound:r.quickFixes,legacySoundSettingsKey:"audioCues.lineHasInlineSuggestion",settingsKey:"accessibility.signals.lineHasInlineSuggestion"})}static{this.terminalQuickFix=a.register({name:(0,s.kg)("accessibilitySignals.terminalQuickFix.name","Terminal Quick Fix"),sound:r.quickFixes,legacySoundSettingsKey:"audioCues.terminalQuickFix",legacyAnnouncementSettingsKey:"accessibility.alert.terminalQuickFix",announcementMessage:(0,s.kg)("accessibility.signals.terminalQuickFix","Quick Fix"),settingsKey:"accessibility.signals.terminalQuickFix"})}static{this.onDebugBreak=a.register({name:(0,s.kg)("accessibilitySignals.onDebugBreak.name","Debugger Stopped on Breakpoint"),sound:r.break,legacySoundSettingsKey:"audioCues.onDebugBreak",legacyAnnouncementSettingsKey:"accessibility.alert.onDebugBreak",announcementMessage:(0,s.kg)("accessibility.signals.onDebugBreak","Breakpoint"),settingsKey:"accessibility.signals.onDebugBreak"})}static{this.noInlayHints=a.register({name:(0,s.kg)("accessibilitySignals.noInlayHints","No Inlay Hints on Line"),sound:r.error,legacySoundSettingsKey:"audioCues.noInlayHints",legacyAnnouncementSettingsKey:"accessibility.alert.noInlayHints",announcementMessage:(0,s.kg)("accessibility.signals.noInlayHints","No Inlay Hints"),settingsKey:"accessibility.signals.noInlayHints"})}static{this.taskCompleted=a.register({name:(0,s.kg)("accessibilitySignals.taskCompleted","Task Completed"),sound:r.taskCompleted,legacySoundSettingsKey:"audioCues.taskCompleted",legacyAnnouncementSettingsKey:"accessibility.alert.taskCompleted",announcementMessage:(0,s.kg)("accessibility.signals.taskCompleted","Task Completed"),settingsKey:"accessibility.signals.taskCompleted"})}static{this.taskFailed=a.register({name:(0,s.kg)("accessibilitySignals.taskFailed","Task Failed"),sound:r.taskFailed,legacySoundSettingsKey:"audioCues.taskFailed",legacyAnnouncementSettingsKey:"accessibility.alert.taskFailed",announcementMessage:(0,s.kg)("accessibility.signals.taskFailed","Task Failed"),settingsKey:"accessibility.signals.taskFailed"})}static{this.terminalCommandFailed=a.register({name:(0,s.kg)("accessibilitySignals.terminalCommandFailed","Terminal Command Failed"),sound:r.error,legacySoundSettingsKey:"audioCues.terminalCommandFailed",legacyAnnouncementSettingsKey:"accessibility.alert.terminalCommandFailed",announcementMessage:(0,s.kg)("accessibility.signals.terminalCommandFailed","Command Failed"),settingsKey:"accessibility.signals.terminalCommandFailed"})}static{this.terminalCommandSucceeded=a.register({name:(0,s.kg)("accessibilitySignals.terminalCommandSucceeded","Terminal Command Succeeded"),sound:r.success,announcementMessage:(0,s.kg)("accessibility.signals.terminalCommandSucceeded","Command Succeeded"),settingsKey:"accessibility.signals.terminalCommandSucceeded"})}static{this.terminalBell=a.register({name:(0,s.kg)("accessibilitySignals.terminalBell","Terminal Bell"),sound:r.terminalBell,legacySoundSettingsKey:"audioCues.terminalBell",legacyAnnouncementSettingsKey:"accessibility.alert.terminalBell",announcementMessage:(0,s.kg)("accessibility.signals.terminalBell","Terminal Bell"),settingsKey:"accessibility.signals.terminalBell"})}static{this.notebookCellCompleted=a.register({name:(0,s.kg)("accessibilitySignals.notebookCellCompleted","Notebook Cell Completed"),sound:r.taskCompleted,legacySoundSettingsKey:"audioCues.notebookCellCompleted",legacyAnnouncementSettingsKey:"accessibility.alert.notebookCellCompleted",announcementMessage:(0,s.kg)("accessibility.signals.notebookCellCompleted","Notebook Cell Completed"),settingsKey:"accessibility.signals.notebookCellCompleted"})}static{this.notebookCellFailed=a.register({name:(0,s.kg)("accessibilitySignals.notebookCellFailed","Notebook Cell Failed"),sound:r.taskFailed,legacySoundSettingsKey:"audioCues.notebookCellFailed",legacyAnnouncementSettingsKey:"accessibility.alert.notebookCellFailed",announcementMessage:(0,s.kg)("accessibility.signals.notebookCellFailed","Notebook Cell Failed"),settingsKey:"accessibility.signals.notebookCellFailed"})}static{this.diffLineInserted=a.register({name:(0,s.kg)("accessibilitySignals.diffLineInserted","Diff Line Inserted"),sound:r.diffLineInserted,legacySoundSettingsKey:"audioCues.diffLineInserted",settingsKey:"accessibility.signals.diffLineInserted"})}static{this.diffLineDeleted=a.register({name:(0,s.kg)("accessibilitySignals.diffLineDeleted","Diff Line Deleted"),sound:r.diffLineDeleted,legacySoundSettingsKey:"audioCues.diffLineDeleted",settingsKey:"accessibility.signals.diffLineDeleted"})}static{this.diffLineModified=a.register({name:(0,s.kg)("accessibilitySignals.diffLineModified","Diff Line Modified"),sound:r.diffLineModified,legacySoundSettingsKey:"audioCues.diffLineModified",settingsKey:"accessibility.signals.diffLineModified"})}static{this.chatRequestSent=a.register({name:(0,s.kg)("accessibilitySignals.chatRequestSent","Chat Request Sent"),sound:r.chatRequestSent,legacySoundSettingsKey:"audioCues.chatRequestSent",legacyAnnouncementSettingsKey:"accessibility.alert.chatRequestSent",announcementMessage:(0,s.kg)("accessibility.signals.chatRequestSent","Chat Request Sent"),settingsKey:"accessibility.signals.chatRequestSent"})}static{this.chatResponseReceived=a.register({name:(0,s.kg)("accessibilitySignals.chatResponseReceived","Chat Response Received"),legacySoundSettingsKey:"audioCues.chatResponseReceived",sound:{randomOneOf:[r.chatResponseReceived1,r.chatResponseReceived2,r.chatResponseReceived3,r.chatResponseReceived4]},settingsKey:"accessibility.signals.chatResponseReceived"})}static{this.progress=a.register({name:(0,s.kg)("accessibilitySignals.progress","Progress"),sound:r.progress,legacySoundSettingsKey:"audioCues.chatResponsePending",legacyAnnouncementSettingsKey:"accessibility.alert.progress",announcementMessage:(0,s.kg)("accessibility.signals.progress","Progress"),settingsKey:"accessibility.signals.progress"})}static{this.clear=a.register({name:(0,s.kg)("accessibilitySignals.clear","Clear"),sound:r.clear,legacySoundSettingsKey:"audioCues.clear",legacyAnnouncementSettingsKey:"accessibility.alert.clear",announcementMessage:(0,s.kg)("accessibility.signals.clear","Clear"),settingsKey:"accessibility.signals.clear"})}static{this.save=a.register({name:(0,s.kg)("accessibilitySignals.save","Save"),sound:r.save,legacySoundSettingsKey:"audioCues.save",legacyAnnouncementSettingsKey:"accessibility.alert.save",announcementMessage:(0,s.kg)("accessibility.signals.save","Save"),settingsKey:"accessibility.signals.save"})}static{this.format=a.register({name:(0,s.kg)("accessibilitySignals.format","Format"),sound:r.format,legacySoundSettingsKey:"audioCues.format",legacyAnnouncementSettingsKey:"accessibility.alert.format",announcementMessage:(0,s.kg)("accessibility.signals.format","Format"),settingsKey:"accessibility.signals.format"})}static{this.voiceRecordingStarted=a.register({name:(0,s.kg)("accessibilitySignals.voiceRecordingStarted","Voice Recording Started"),sound:r.voiceRecordingStarted,legacySoundSettingsKey:"audioCues.voiceRecordingStarted",settingsKey:"accessibility.signals.voiceRecordingStarted"})}static{this.voiceRecordingStopped=a.register({name:(0,s.kg)("accessibilitySignals.voiceRecordingStopped","Voice Recording Stopped"),sound:r.voiceRecordingStopped,legacySoundSettingsKey:"audioCues.voiceRecordingStopped",settingsKey:"accessibility.signals.voiceRecordingStopped"})}}},87285:(e,t,i)=>{"use strict";i.d(t,{A:()=>o});var s,n=i(59284);function r(){return r=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{Ho:()=>Qt,kI:()=>Xt,Bz:()=>Wt});var s=i(25890),n=i(47661),r=i(64383),o=i(41234),a=i(5662),c=i(91508),l=i(79400),h=i(64454),d=i(93895),u=i(83069),g=i(36677),p=i(75326),m=i(24329),f=i(10154),_=i(17469),v=i(16223),C=i(12296),E=i(56772);class b{constructor(e,t,i,s){this.range=e,this.nestingLevel=t,this.nestingLevelOfEqualBracketType=i,this.isInvalid=s}}class S{constructor(e,t,i,s,n,r){this.range=e,this.openingBracketRange=t,this.closingBracketRange=i,this.nestingLevel=s,this.nestingLevelOfEqualBracketType=n,this.bracketPairNode=r}get openingBracketInfo(){return this.bracketPairNode.openingBracket.bracketInfo}}class y extends S{constructor(e,t,i,s,n,r,o){super(e,t,i,s,n,r),this.minVisibleColumnIndentation=o}}var w=i(94650),R=i(93630),L=i(19131),T=i(19562),x=i(32956),k=i(51934),A=i(84084);class N extends a.jG{didLanguageChange(e){return this.brackets.didLanguageChange(e)}constructor(e,t){if(super(),this.textModel=e,this.getLanguageConfiguration=t,this.didChangeEmitter=new o.vl,this.denseKeyProvider=new x.Mg,this.brackets=new R.Z(this.denseKeyProvider,this.getLanguageConfiguration),this.onDidChange=this.didChangeEmitter.event,this.queuedTextEditsForInitialAstWithoutTokens=[],this.queuedTextEdits=[],e.tokenization.hasTokens)2===e.tokenization.backgroundTokenizationState?(this.initialAstWithoutTokens=void 0,this.astWithTokens=this.parseDocumentFromTextBuffer([],void 0,!1)):(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer([],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens);else{const e=this.brackets.getSingleLanguageBracketTokens(this.textModel.getLanguageId()),t=new k._(this.textModel.getValue(),e);this.initialAstWithoutTokens=(0,T.T)(t,[],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens}}handleDidChangeBackgroundTokenizationState(){if(2===this.textModel.tokenization.backgroundTokenizationState){const e=void 0===this.initialAstWithoutTokens;this.initialAstWithoutTokens=void 0,e||this.didChangeEmitter.fire()}}handleDidChangeTokens({ranges:e}){const t=e.map((e=>new w.c((0,L.qe)(e.fromLineNumber-1,0),(0,L.qe)(e.toLineNumber,0),(0,L.qe)(e.toLineNumber-e.fromLineNumber+1,0))));this.handleEdits(t,!0),this.initialAstWithoutTokens||this.didChangeEmitter.fire()}handleContentChanged(e){const t=w.c.fromModelContentChanges(e.changes);this.handleEdits(t,!1)}handleEdits(e,t){const i=(0,A.M)(this.queuedTextEdits,e);this.queuedTextEdits=i,this.initialAstWithoutTokens&&!t&&(this.queuedTextEditsForInitialAstWithoutTokens=(0,A.M)(this.queuedTextEditsForInitialAstWithoutTokens,e))}flushQueue(){this.queuedTextEdits.length>0&&(this.astWithTokens=this.parseDocumentFromTextBuffer(this.queuedTextEdits,this.astWithTokens,!1),this.queuedTextEdits=[]),this.queuedTextEditsForInitialAstWithoutTokens.length>0&&(this.initialAstWithoutTokens&&(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer(this.queuedTextEditsForInitialAstWithoutTokens,this.initialAstWithoutTokens,!1)),this.queuedTextEditsForInitialAstWithoutTokens=[])}parseDocumentFromTextBuffer(e,t,i){const s=t,n=new k.tk(this.textModel,this.brackets);return(0,T.T)(n,e,s,i)}getBracketsInRange(e,t){this.flushQueue();const i=(0,L.qe)(e.startLineNumber-1,e.startColumn-1),n=(0,L.qe)(e.endLineNumber-1,e.endColumn-1);return new s.c1((e=>{const s=this.initialAstWithoutTokens||this.astWithTokens;D(s,L.Vp,s.length,i,n,e,0,0,new Map,t)}))}getBracketPairsInRange(e,t){this.flushQueue();const i=(0,L.VL)(e.getStartPosition()),n=(0,L.VL)(e.getEndPosition());return new s.c1((e=>{const s=this.initialAstWithoutTokens||this.astWithTokens,r=new M(e,t,this.textModel);P(s,L.Vp,s.length,i,n,r,0,new Map)}))}getFirstBracketAfter(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return O(t,L.Vp,t.length,(0,L.VL)(e))}getFirstBracketBefore(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return I(t,L.Vp,t.length,(0,L.VL)(e))}}function I(e,t,i,s){if(4===e.kind||2===e.kind){const n=[];for(const s of e.children)i=(0,L.QB)(t,s.length),n.push({nodeOffsetStart:t,nodeOffsetEnd:i}),t=i;for(let t=n.length-1;t>=0;t--){const{nodeOffsetStart:i,nodeOffsetEnd:r}=n[t];if((0,L.zG)(i,s)){const n=I(e.children[t],i,r,s);if(n)return n}}return null}if(3===e.kind)return null;if(1===e.kind){const s=(0,L.Qx)(t,i);return{bracketInfo:e.bracketInfo,range:s}}return null}function O(e,t,i,s){if(4===e.kind||2===e.kind){for(const n of e.children){if(i=(0,L.QB)(t,n.length),(0,L.zG)(s,i)){const e=O(n,t,i,s);if(e)return e}t=i}return null}if(3===e.kind)return null;if(1===e.kind){const s=(0,L.Qx)(t,i);return{bracketInfo:e.bracketInfo,range:s}}return null}function D(e,t,i,s,n,r,o,a,c,l,h=!1){if(o>200)return!0;e:for(;;)switch(e.kind){case 4:{const a=e.childrenLength;for(let h=0;h200)return!0;let c=!0;if(2===e.kind){let l=0;if(a){let t=a.get(e.openingBracket.text);void 0===t&&(t=0),l=t,t++,a.set(e.openingBracket.text,t)}const h=(0,L.QB)(t,e.openingBracket.length);let d=-1;if(r.includeMinIndentation&&(d=e.computeMinIndentation(t,r.textModel)),c=r.push(new y((0,L.Qx)(t,i),(0,L.Qx)(t,h),e.closingBracket?(0,L.Qx)((0,L.QB)(h,e.child?.length||L.Vp),i):void 0,o,l,e,d)),t=h,c&&e.child){const l=e.child;if(i=(0,L.QB)(t,l.length),(0,L.vr)(t,n)&&(0,L.o0)(i,s)&&(c=P(l,t,i,s,n,r,o+1,a),!c))return!1}a?.set(e.openingBracket.text,l)}else{let i=t;for(const t of e.children){const e=i;if(i=(0,L.QB)(i,t.length),(0,L.vr)(e,n)&&(0,L.vr)(s,i)&&(c=P(t,e,i,s,n,r,o,a),!c))return!1}}return c}class F extends a.jG{get canBuildAST(){return this.textModel.getValueLength()<=5e6}constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t,this.bracketPairsTree=this._register(new a.HE),this.onDidChangeEmitter=new o.vl,this.onDidChange=this.onDidChangeEmitter.event,this.bracketsRequested=!1}handleLanguageConfigurationServiceChange(e){e.languageId&&!this.bracketPairsTree.value?.object.didLanguageChange(e.languageId)||(this.bracketPairsTree.clear(),this.updateBracketPairsTree())}handleDidChangeOptions(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeLanguage(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeContent(e){this.bracketPairsTree.value?.object.handleContentChanged(e)}handleDidChangeBackgroundTokenizationState(){this.bracketPairsTree.value?.object.handleDidChangeBackgroundTokenizationState()}handleDidChangeTokens(e){this.bracketPairsTree.value?.object.handleDidChangeTokens(e)}updateBracketPairsTree(){if(this.bracketsRequested&&this.canBuildAST){if(!this.bracketPairsTree.value){const i=new a.Cm;this.bracketPairsTree.value=(e=i.add(new N(this.textModel,(e=>this.languageConfigurationService.getLanguageConfiguration(e)))),t=i,{object:e,dispose:()=>t?.dispose()}),i.add(this.bracketPairsTree.value.object.onDidChange((e=>this.onDidChangeEmitter.fire(e)))),this.onDidChangeEmitter.fire()}}else this.bracketPairsTree.value&&(this.bracketPairsTree.clear(),this.onDidChangeEmitter.fire());var e,t}getBracketPairsInRange(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!1)||s.c1.empty}getBracketPairsInRangeWithMinIndentation(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!0)||s.c1.empty}getBracketsInRange(e,t=!1){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketsInRange(e,t)||s.c1.empty}findMatchingBracketUp(e,t,i){const s=this.textModel.validatePosition(t),n=this.textModel.getLanguageIdAtPosition(s.lineNumber,s.column);if(this.canBuildAST){const i=this.languageConfigurationService.getLanguageConfiguration(n).bracketsNew.getClosingBracketInfo(e);if(!i)return null;const s=this.getBracketPairsInRange(g.Q.fromPositions(t,t)).findLast((e=>i.closes(e.openingBracketInfo)));return s?s.openingBracketRange:null}{const t=e.toLowerCase(),r=this.languageConfigurationService.getLanguageConfiguration(n).brackets;if(!r)return null;const o=r.textIsBracket[t];return o?B(this._findMatchingBracketUp(o,s,U(i))):null}}matchBracket(e,t){if(this.canBuildAST){const t=this.getBracketPairsInRange(g.Q.fromPositions(e,e)).filter((t=>void 0!==t.closingBracketRange&&(t.openingBracketRange.containsPosition(e)||t.closingBracketRange.containsPosition(e)))).findLastMaxBy((0,s.VE)((t=>t.openingBracketRange.containsPosition(e)?t.openingBracketRange:t.closingBracketRange),g.Q.compareRangesUsingStarts));return t?[t.openingBracketRange,t.closingBracketRange]:null}{const i=U(t);return this._matchBracket(this.textModel.validatePosition(e),i)}}_establishBracketSearchOffsets(e,t,i,s){const n=t.getCount(),r=t.getLanguageId(s);let o=Math.max(0,e.column-1-i.maxBracketLength);for(let c=s-1;c>=0;c--){const e=t.getEndOffset(c);if(e<=o)break;if((0,C.Yo)(t.getStandardTokenType(c))||t.getLanguageId(c)!==r){o=e;break}}let a=Math.min(t.getLineContent().length,e.column-1+i.maxBracketLength);for(let c=s+1;c=a)break;if((0,C.Yo)(t.getStandardTokenType(c))||t.getLanguageId(c)!==r){a=e;break}}return{searchStartOffset:o,searchEndOffset:a}}_matchBracket(e,t){const i=e.lineNumber,s=this.textModel.tokenization.getLineTokens(i),n=this.textModel.getLineContent(i),r=s.findTokenIndexAtOffset(e.column-1);if(r<0)return null;const o=this.languageConfigurationService.getLanguageConfiguration(s.getLanguageId(r)).brackets;if(o&&!(0,C.Yo)(s.getStandardTokenType(r))){let{searchStartOffset:a,searchEndOffset:c}=this._establishBracketSearchOffsets(e,s,o,r),l=null;for(;;){const s=E.Fu.findNextBracketInRange(o.forwardRegex,i,n,a,c);if(!s)break;if(s.startColumn<=e.column&&e.column<=s.endColumn){const e=n.substring(s.startColumn-1,s.endColumn-1).toLowerCase(),i=this._matchFoundBracket(s,o.textIsBracket[e],o.textIsOpenBracket[e],t);if(i){if(i instanceof H)return null;l=i}}a=s.endColumn-1}if(l)return l}if(r>0&&s.getStartOffset(r)===e.column-1){const o=r-1,a=this.languageConfigurationService.getLanguageConfiguration(s.getLanguageId(o)).brackets;if(a&&!(0,C.Yo)(s.getStandardTokenType(o))){const{searchStartOffset:r,searchEndOffset:c}=this._establishBracketSearchOffsets(e,s,a,o),l=E.Fu.findPrevBracketInRange(a.reversedRegex,i,n,r,c);if(l&&l.startColumn<=e.column&&e.column<=l.endColumn){const e=n.substring(l.startColumn-1,l.endColumn-1).toLowerCase(),i=this._matchFoundBracket(l,a.textIsBracket[e],a.textIsOpenBracket[e],t);if(i)return i instanceof H?null:i}}}return null}_matchFoundBracket(e,t,i,s){if(!t)return null;const n=i?this._findMatchingBracketDown(t,e.getEndPosition(),s):this._findMatchingBracketUp(t,e.getStartPosition(),s);return n?n instanceof H?n:[e,n]:null}_findMatchingBracketUp(e,t,i){const s=e.languageId,n=e.reversedRegex;let r=-1,o=0;const a=(t,s,a,c)=>{for(;;){if(i&&++o%100===0&&!i())return H.INSTANCE;const l=E.Fu.findPrevBracketInRange(n,t,s,a,c);if(!l)break;const h=s.substring(l.startColumn-1,l.endColumn-1).toLowerCase();if(e.isOpen(h)?r++:e.isClose(h)&&r--,0===r)return l;c=l.startColumn-1}return null};for(let c=t.lineNumber;c>=1;c--){const e=this.textModel.tokenization.getLineTokens(c),i=e.getCount(),n=this.textModel.getLineContent(c);let r=i-1,o=n.length,l=n.length;c===t.lineNumber&&(r=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,l=t.column-1);let h=!0;for(;r>=0;r--){const t=e.getLanguageId(r)===s&&!(0,C.Yo)(e.getStandardTokenType(r));if(t)h?o=e.getStartOffset(r):(o=e.getStartOffset(r),l=e.getEndOffset(r));else if(h&&o!==l){const e=a(c,n,o,l);if(e)return e}h=t}if(h&&o!==l){const e=a(c,n,o,l);if(e)return e}}return null}_findMatchingBracketDown(e,t,i){const s=e.languageId,n=e.forwardRegex;let r=1,o=0;const a=(t,s,a,c)=>{for(;;){if(i&&++o%100===0&&!i())return H.INSTANCE;const l=E.Fu.findNextBracketInRange(n,t,s,a,c);if(!l)break;const h=s.substring(l.startColumn-1,l.endColumn-1).toLowerCase();if(e.isOpen(h)?r++:e.isClose(h)&&r--,0===r)return l;a=l.endColumn-1}return null},c=this.textModel.getLineCount();for(let l=t.lineNumber;l<=c;l++){const e=this.textModel.tokenization.getLineTokens(l),i=e.getCount(),n=this.textModel.getLineContent(l);let r=0,o=0,c=0;l===t.lineNumber&&(r=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,c=t.column-1);let h=!0;for(;r=1;r--){const e=this.textModel.tokenization.getLineTokens(r),o=e.getCount(),a=this.textModel.getLineContent(r);let c=o-1,l=a.length,h=a.length;if(r===t.lineNumber){c=e.findTokenIndexAtOffset(t.column-1),l=t.column-1,h=t.column-1;const r=e.getLanguageId(c);i!==r&&(i=r,s=this.languageConfigurationService.getLanguageConfiguration(i).brackets,n=this.languageConfigurationService.getLanguageConfiguration(i).bracketsNew)}let d=!0;for(;c>=0;c--){const t=e.getLanguageId(c);if(i!==t){if(s&&n&&d&&l!==h){const e=E.Fu.findPrevBracketInRange(s.reversedRegex,r,a,l,h);if(e)return this._toFoundBracket(n,e);d=!1}i=t,s=this.languageConfigurationService.getLanguageConfiguration(i).brackets,n=this.languageConfigurationService.getLanguageConfiguration(i).bracketsNew}const o=!!s&&!(0,C.Yo)(e.getStandardTokenType(c));if(o)d?l=e.getStartOffset(c):(l=e.getStartOffset(c),h=e.getEndOffset(c));else if(n&&s&&d&&l!==h){const e=E.Fu.findPrevBracketInRange(s.reversedRegex,r,a,l,h);if(e)return this._toFoundBracket(n,e)}d=o}if(n&&s&&d&&l!==h){const e=E.Fu.findPrevBracketInRange(s.reversedRegex,r,a,l,h);if(e)return this._toFoundBracket(n,e)}}return null}findNextBracket(e){const t=this.textModel.validatePosition(e);if(this.canBuildAST)return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getFirstBracketAfter(t)||null;const i=this.textModel.getLineCount();let s=null,n=null,r=null;for(let o=t.lineNumber;o<=i;o++){const e=this.textModel.tokenization.getLineTokens(o),i=e.getCount(),a=this.textModel.getLineContent(o);let c=0,l=0,h=0;if(o===t.lineNumber){c=e.findTokenIndexAtOffset(t.column-1),l=t.column-1,h=t.column-1;const i=e.getLanguageId(c);s!==i&&(s=i,n=this.languageConfigurationService.getLanguageConfiguration(s).brackets,r=this.languageConfigurationService.getLanguageConfiguration(s).bracketsNew)}let d=!0;for(;cvoid 0!==t.closingBracketRange&&t.range.strictContainsRange(e)));return t?[t.openingBracketRange,t.closingBracketRange]:null}const s=U(t),n=this.textModel.getLineCount(),r=new Map;let o=[];const a=(e,t)=>{if(!r.has(e)){const i=[];for(let e=0,s=t?t.brackets.length:0;e{for(;;){if(s&&++c%100===0&&!s())return H.INSTANCE;const a=E.Fu.findNextBracketInRange(e.forwardRegex,t,i,n,r);if(!a)break;const l=i.substring(a.startColumn-1,a.endColumn-1).toLowerCase(),h=e.textIsBracket[l];if(h&&(h.isOpen(l)?o[h.index]++:h.isClose(l)&&o[h.index]--,-1===o[h.index]))return this._matchFoundBracket(a,h,!1,s);n=a.endColumn-1}return null};let h=null,d=null;for(let u=i.lineNumber;u<=n;u++){const e=this.textModel.tokenization.getLineTokens(u),t=e.getCount(),s=this.textModel.getLineContent(u);let n=0,r=0,o=0;if(u===i.lineNumber){n=e.findTokenIndexAtOffset(i.column-1),r=i.column-1,o=i.column-1;const t=e.getLanguageId(n);h!==t&&(h=t,d=this.languageConfigurationService.getLanguageConfiguration(h).brackets,a(h,d))}let c=!0;for(;n!0;{const t=Date.now();return()=>Date.now()-t<=e}}class H{static{this.INSTANCE=new H}constructor(){this._searchCanceledBrand=void 0}}function B(e){return e instanceof H?null:e}var W=i(87119),V=i(47612);class z extends a.jG{constructor(e){super(),this.textModel=e,this.colorProvider=new G,this.onDidChangeEmitter=new o.vl,this.onDidChange=this.onDidChangeEmitter.event,this.colorizationOptions=e.getOptions().bracketPairColorizationOptions,this._register(e.bracketPairs.onDidChange((e=>{this.onDidChangeEmitter.fire()})))}handleDidChangeOptions(e){this.colorizationOptions=this.textModel.getOptions().bracketPairColorizationOptions}getDecorationsInRange(e,t,i,s){if(s)return[];if(void 0===t)return[];if(!this.colorizationOptions.enabled)return[];return this.textModel.bracketPairs.getBracketsInRange(e,!0).map((e=>({id:`bracket${e.range.toString()}-${e.nestingLevel}`,options:{description:"BracketPairColorization",inlineClassName:this.colorProvider.getInlineClassName(e,this.colorizationOptions.independentColorPoolPerBracketType)},ownerId:0,range:e.range}))).toArray()}getAllDecorations(e,t){return void 0===e?[]:this.colorizationOptions.enabled?this.getDecorationsInRange(new g.Q(1,1,this.textModel.getLineCount(),1),e,t):[]}}class G{constructor(){this.unexpectedClosingBracketClassName="unexpected-closing-bracket"}getInlineClassName(e,t){return e.isInvalid?this.unexpectedClosingBracketClassName:this.getInlineClassNameOfLevel(t?e.nestingLevelOfEqualBracketType:e.nestingLevel)}getInlineClassNameOfLevel(e){return"bracket-highlighting-"+e%30}}(0,V.zy)(((e,t)=>{const i=[W.sN,W.lQ,W.ss,W.l5,W.sH,W.zp],s=new G;t.addRule(`.monaco-editor .${s.unexpectedClosingBracketClassName} { color: ${e.getColor(W.s7)}; }`);const n=i.map((t=>e.getColor(t))).filter((e=>!!e)).filter((e=>!e.isTransparent()));for(let r=0;r<30;r++){const e=n[r%n.length];t.addRule(`.monaco-editor .${s.getInlineClassNameOfLevel(r)} { color: ${e}; }`)}}));var j=i(26656),K=i(53450);class Y{constructor(){this.spacesDiff=0,this.looksLikeAlignment=!1}}function q(e,t,i,s,n){let r;for(n.spacesDiff=0,n.looksLikeAlignment=!1,r=0;r0&&a>0)return;if(c>0&&l>0)return;const h=Math.abs(a-l),d=Math.abs(o-c);if(0===h)return n.spacesDiff=d,void(d>0&&0<=c-1&&c-10?n++:m>1&&r++,q(o,a,c,p,h),h.looksLikeAlignment&&(!i||t!==h.spacesDiff))continue;const _=h.spacesDiff;_<=8&&l[_]++,o=c,a=p}let d=i;n!==r&&(d=n{const i=l[t];i>e&&(e=i,u=t)})),4===u&&l[4]>0&&l[2]>0&&l[2]>=l[4]/2&&(u=2)}return{insertSpaces:d,tabSize:u}}function Q(e){return(1&e.metadata)>>>0}function X(e,t){e.metadata=254&e.metadata|t}function Z(e){return(2&e.metadata)>>>1===1}function J(e,t){e.metadata=253&e.metadata|(t?1:0)<<1}function ee(e){return(4&e.metadata)>>>2===1}function te(e,t){e.metadata=251&e.metadata|(t?1:0)<<2}function ie(e){return(64&e.metadata)>>>6===1}function se(e,t){e.metadata=191&e.metadata|(t?1:0)<<6}function ne(e,t){e.metadata=231&e.metadata|t<<3}function re(e,t){e.metadata=223&e.metadata|(t?1:0)<<5}class oe{constructor(e,t,i){this.metadata=0,this.parent=this,this.left=this,this.right=this,X(this,1),this.start=t,this.end=i,this.delta=0,this.maxEnd=i,this.id=e,this.ownerId=0,this.options=null,te(this,!1),se(this,!1),ne(this,1),re(this,!1),this.cachedVersionId=0,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=i,this.range=null,J(this,!1)}reset(e,t,i,s){this.start=t,this.end=i,this.maxEnd=i,this.cachedVersionId=e,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=i,this.range=s}setOptions(e){this.options=e;const t=this.options.className;te(this,"squiggly-error"===t||"squiggly-warning"===t||"squiggly-info"===t),se(this,null!==this.options.glyphMarginClassName),ne(this,this.options.stickiness),re(this,this.options.collapseOnReplaceEdit)}setCachedOffsets(e,t,i){this.cachedVersionId!==i&&(this.range=null),this.cachedVersionId=i,this.cachedAbsoluteStart=e,this.cachedAbsoluteEnd=t}detach(){this.parent=null,this.left=null,this.right=null}}const ae=new oe(null,0,0);ae.parent=ae,ae.left=ae,ae.right=ae,X(ae,0);class ce{constructor(){this.root=ae,this.requestNormalizeDelta=!1}intervalSearch(e,t,i,s,n,r){return this.root===ae?[]:function(e,t,i,s,n,r,o){let a=e.root,c=0,l=0,h=0,d=0;const u=[];let g=0;for(;a!==ae;)if(Z(a))J(a.left,!1),J(a.right,!1),a===a.parent.right&&(c-=a.parent.delta),a=a.parent;else{if(!Z(a.left)){if(l=c+a.maxEnd,li)J(a,!0);else{if(d=c+a.end,d>=t){a.setCachedOffsets(h,d,r);let e=!0;s&&a.ownerId&&a.ownerId!==s&&(e=!1),n&&ee(a)&&(e=!1),o&&!ie(a)&&(e=!1),e&&(u[g++]=a)}J(a,!0),a.right===ae||Z(a.right)||(c+=a.delta,a=a.right)}}return J(e.root,!1),u}(this,e,t,i,s,n,r)}search(e,t,i,s){return this.root===ae?[]:function(e,t,i,s,n){let r=e.root,o=0,a=0,c=0;const l=[];let h=0;for(;r!==ae;){if(Z(r)){J(r.left,!1),J(r.right,!1),r===r.parent.right&&(o-=r.parent.delta),r=r.parent;continue}if(r.left!==ae&&!Z(r.left)){r=r.left;continue}a=o+r.start,c=o+r.end,r.setCachedOffsets(a,c,s);let e=!0;t&&r.ownerId&&r.ownerId!==t&&(e=!1),i&&ee(r)&&(e=!1),n&&!ie(r)&&(e=!1),e&&(l[h++]=r),J(r,!0),r.right===ae||Z(r.right)||(o+=r.delta,r=r.right)}return J(e.root,!1),l}(this,e,t,i,s)}collectNodesFromOwner(e){return function(e,t){let i=e.root;const s=[];let n=0;for(;i!==ae;)Z(i)?(J(i.left,!1),J(i.right,!1),i=i.parent):i.left===ae||Z(i.left)?(i.ownerId===t&&(s[n++]=i),J(i,!0),i.right===ae||Z(i.right)||(i=i.right)):i=i.left;return J(e.root,!1),s}(this,e)}collectNodesPostOrder(){return function(e){let t=e.root;const i=[];let s=0;for(;t!==ae;)Z(t)?(J(t.left,!1),J(t.right,!1),t=t.parent):t.left===ae||Z(t.left)?t.right===ae||Z(t.right)?(i[s++]=t,J(t,!0)):t=t.right:t=t.left;return J(e.root,!1),i}(this)}insert(e){de(this,e),this._normalizeDeltaIfNecessary()}delete(e){ue(this,e),this._normalizeDeltaIfNecessary()}resolveNode(e,t){const i=e;let s=0;for(;e!==this.root;)e===e.parent.right&&(s+=e.parent.delta),e=e.parent;const n=i.start+s,r=i.end+s;i.setCachedOffsets(n,r,t)}acceptReplace(e,t,i,s){const n=function(e,t,i){let s=e.root,n=0,r=0,o=0,a=0;const c=[];let l=0;for(;s!==ae;)if(Z(s))J(s.left,!1),J(s.right,!1),s===s.parent.right&&(n-=s.parent.delta),s=s.parent;else{if(!Z(s.left)){if(r=n+s.maxEnd,ri?J(s,!0):(a=n+s.end,a>=t&&(s.setCachedOffsets(o,a,0),c[l++]=s),J(s,!0),s.right===ae||Z(s.right)||(n+=s.delta,s=s.right))}return J(e.root,!1),c}(this,e,e+t);for(let r=0,o=n.length;ri?(n.start+=c,n.end+=c,n.delta+=c,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),J(n,!0)):(J(n,!0),n.right===ae||Z(n.right)||(r+=n.delta,n=n.right))}J(e.root,!1)}(this,e,e+t,i),this._normalizeDeltaIfNecessary();for(let r=0,o=n.length;ri)&&(1!==s&&(2===s||t))}function he(e,t,i,s,n){const r=function(e){return(24&e.metadata)>>>3}(e),o=0===r||2===r,a=1===r||2===r,c=i-t,l=s,h=Math.min(c,l),d=e.start;let u=!1;const g=e.end;let p=!1;t<=d&&g<=i&&function(e){return(32&e.metadata)>>>5===1}(e)&&(e.start=t,u=!0,e.end=t,p=!0);{const e=n?1:c>0?2:0;!u&&le(d,o,t,e)&&(u=!0),!p&&le(g,a,t,e)&&(p=!0)}if(h>0&&!n){const e=c>l?2:0;!u&&le(d,o,t+h,e)&&(u=!0),!p&&le(g,a,t+h,e)&&(p=!0)}{const s=n?1:0;!u&&le(d,o,i,s)&&(e.start=t+l,u=!0),!p&&le(g,a,i,s)&&(e.end=t+l,p=!0)}const m=l-c;u||(e.start=Math.max(0,d+m)),p||(e.end=Math.max(0,g+m)),e.start>e.end&&(e.end=e.start)}function de(e,t){if(e.root===ae)return t.parent=ae,t.left=ae,t.right=ae,X(t,0),e.root=t,e.root;!function(e,t){let i=0,s=e.root;const n=t.start,r=t.end;for(;;){if(Ce(n,r,s.start+i,s.end+i)<0){if(s.left===ae){t.start-=i,t.end-=i,t.maxEnd-=i,s.left=t;break}s=s.left}else{if(s.right===ae){t.start-=i+s.delta,t.end-=i+s.delta,t.maxEnd-=i+s.delta,s.right=t;break}i+=s.delta,s=s.right}}t.parent=s,t.left=ae,t.right=ae,X(t,1)}(e,t),ve(t.parent);let i=t;for(;i!==e.root&&1===Q(i.parent);)if(i.parent===i.parent.parent.left){const t=i.parent.parent.right;1===Q(t)?(X(i.parent,0),X(t,0),X(i.parent.parent,1),i=i.parent.parent):(i===i.parent.right&&(i=i.parent,pe(e,i)),X(i.parent,0),X(i.parent.parent,1),me(e,i.parent.parent))}else{const t=i.parent.parent.left;1===Q(t)?(X(i.parent,0),X(t,0),X(i.parent.parent,1),i=i.parent.parent):(i===i.parent.left&&(i=i.parent,me(e,i)),X(i.parent,0),X(i.parent.parent,1),pe(e,i.parent.parent))}return X(e.root,0),t}function ue(e,t){let i,s;if(t.left===ae?(i=t.right,s=t,i.delta+=t.delta,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),i.start+=t.delta,i.end+=t.delta):t.right===ae?(i=t.left,s=t):(s=function(e){for(;e.left!==ae;)e=e.left;return e}(t.right),i=s.right,i.start+=s.delta,i.end+=s.delta,i.delta+=s.delta,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),s.start+=t.delta,s.end+=t.delta,s.delta=t.delta,(s.delta<-1073741824||s.delta>1073741824)&&(e.requestNormalizeDelta=!0)),s===e.root)return e.root=i,X(i,0),t.detach(),ge(),_e(i),void(e.root.parent=ae);const n=1===Q(s);if(s===s.parent.left?s.parent.left=i:s.parent.right=i,s===t?i.parent=s.parent:(s.parent===t?i.parent=s:i.parent=s.parent,s.left=t.left,s.right=t.right,s.parent=t.parent,X(s,Q(t)),t===e.root?e.root=s:t===t.parent.left?t.parent.left=s:t.parent.right=s,s.left!==ae&&(s.left.parent=s),s.right!==ae&&(s.right.parent=s)),t.detach(),n)return ve(i.parent),s!==t&&(ve(s),ve(s.parent)),void ge();let r;for(ve(i),ve(i.parent),s!==t&&(ve(s),ve(s.parent));i!==e.root&&0===Q(i);)i===i.parent.left?(r=i.parent.right,1===Q(r)&&(X(r,0),X(i.parent,1),pe(e,i.parent),r=i.parent.right),0===Q(r.left)&&0===Q(r.right)?(X(r,1),i=i.parent):(0===Q(r.right)&&(X(r.left,0),X(r,1),me(e,r),r=i.parent.right),X(r,Q(i.parent)),X(i.parent,0),X(r.right,0),pe(e,i.parent),i=e.root)):(r=i.parent.left,1===Q(r)&&(X(r,0),X(i.parent,1),me(e,i.parent),r=i.parent.left),0===Q(r.left)&&0===Q(r.right)?(X(r,1),i=i.parent):(0===Q(r.left)&&(X(r.right,0),X(r,1),pe(e,r),r=i.parent.left),X(r,Q(i.parent)),X(i.parent,0),X(r.left,0),me(e,i.parent),i=e.root));X(i,0),ge()}function ge(){ae.parent=ae,ae.delta=0,ae.start=0,ae.end=0}function pe(e,t){const i=t.right;i.delta+=t.delta,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),i.start+=t.delta,i.end+=t.delta,t.right=i.left,i.left!==ae&&(i.left.parent=t),i.parent=t.parent,t.parent===ae?e.root=i:t===t.parent.left?t.parent.left=i:t.parent.right=i,i.left=t,t.parent=i,_e(t),_e(i)}function me(e,t){const i=t.left;t.delta-=i.delta,(t.delta<-1073741824||t.delta>1073741824)&&(e.requestNormalizeDelta=!0),t.start-=i.delta,t.end-=i.delta,t.left=i.right,i.right!==ae&&(i.right.parent=t),i.parent=t.parent,t.parent===ae?e.root=i:t===t.parent.right?t.parent.right=i:t.parent.left=i,i.right=t,t.parent=i,_e(t),_e(i)}function fe(e){let t=e.end;if(e.left!==ae){const i=e.left.maxEnd;i>t&&(t=i)}if(e.right!==ae){const i=e.right.maxEnd+e.delta;i>t&&(t=i)}return t}function _e(e){e.maxEnd=fe(e)}function ve(e){for(;e!==ae;){const t=fe(e);if(e.maxEnd===t)return;e.maxEnd=t,e=e.parent}}function Ce(e,t,i,s){return e===i?t-s:e-i}class Ee{constructor(e,t){this.piece=e,this.color=t,this.size_left=0,this.lf_left=0,this.parent=this,this.left=this,this.right=this}next(){if(this.right!==be)return Se(this.right);let e=this;for(;e.parent!==be&&e.parent.left!==e;)e=e.parent;return e.parent===be?be:e.parent}prev(){if(this.left!==be)return ye(this.left);let e=this;for(;e.parent!==be&&e.parent.right!==e;)e=e.parent;return e.parent===be?be:e.parent}detach(){this.parent=null,this.left=null,this.right=null}}const be=new Ee(null,0);function Se(e){for(;e.left!==be;)e=e.left;return e}function ye(e){for(;e.right!==be;)e=e.right;return e}function we(e){return e===be?0:e.size_left+e.piece.length+we(e.right)}function Re(e){return e===be?0:e.lf_left+e.piece.lineFeedCnt+Re(e.right)}function Le(){be.parent=be}function Te(e,t){const i=t.right;i.size_left+=t.size_left+(t.piece?t.piece.length:0),i.lf_left+=t.lf_left+(t.piece?t.piece.lineFeedCnt:0),t.right=i.left,i.left!==be&&(i.left.parent=t),i.parent=t.parent,t.parent===be?e.root=i:t.parent.left===t?t.parent.left=i:t.parent.right=i,i.left=t,t.parent=i}function xe(e,t){const i=t.left;t.left=i.right,i.right!==be&&(i.right.parent=t),i.parent=t.parent,t.size_left-=i.size_left+(i.piece?i.piece.length:0),t.lf_left-=i.lf_left+(i.piece?i.piece.lineFeedCnt:0),t.parent===be?e.root=i:t===t.parent.right?t.parent.right=i:t.parent.left=i,i.right=t,t.parent=i}function ke(e,t){let i,s;if(t.left===be?(s=t,i=s.right):t.right===be?(s=t,i=s.left):(s=Se(t.right),i=s.right),s===e.root)return e.root=i,i.color=0,t.detach(),Le(),void(e.root.parent=be);const n=1===s.color;if(s===s.parent.left?s.parent.left=i:s.parent.right=i,s===t?(i.parent=s.parent,Ie(e,i)):(s.parent===t?i.parent=s:i.parent=s.parent,Ie(e,i),s.left=t.left,s.right=t.right,s.parent=t.parent,s.color=t.color,t===e.root?e.root=s:t===t.parent.left?t.parent.left=s:t.parent.right=s,s.left!==be&&(s.left.parent=s),s.right!==be&&(s.right.parent=s),s.size_left=t.size_left,s.lf_left=t.lf_left,Ie(e,s)),t.detach(),i.parent.left===i){const t=we(i),s=Re(i);if(t!==i.parent.size_left||s!==i.parent.lf_left){const n=t-i.parent.size_left,r=s-i.parent.lf_left;i.parent.size_left=t,i.parent.lf_left=s,Ne(e,i.parent,n,r)}}if(Ie(e,i.parent),n)return void Le();let r;for(;i!==e.root&&0===i.color;)i===i.parent.left?(r=i.parent.right,1===r.color&&(r.color=0,i.parent.color=1,Te(e,i.parent),r=i.parent.right),0===r.left.color&&0===r.right.color?(r.color=1,i=i.parent):(0===r.right.color&&(r.left.color=0,r.color=1,xe(e,r),r=i.parent.right),r.color=i.parent.color,i.parent.color=0,r.right.color=0,Te(e,i.parent),i=e.root)):(r=i.parent.left,1===r.color&&(r.color=0,i.parent.color=1,xe(e,i.parent),r=i.parent.left),0===r.left.color&&0===r.right.color?(r.color=1,i=i.parent):(0===r.left.color&&(r.right.color=0,r.color=1,Te(e,r),r=i.parent.left),r.color=i.parent.color,i.parent.color=0,r.left.color=0,xe(e,i.parent),i=e.root));i.color=0,Le()}function Ae(e,t){for(Ie(e,t);t!==e.root&&1===t.parent.color;)if(t.parent===t.parent.parent.left){const i=t.parent.parent.right;1===i.color?(t.parent.color=0,i.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.right&&Te(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,xe(e,t.parent.parent))}else{const i=t.parent.parent.left;1===i.color?(t.parent.color=0,i.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.left&&xe(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,Te(e,t.parent.parent))}e.root.color=0}function Ne(e,t,i,s){for(;t!==e.root&&t!==be;)t.parent.left===t&&(t.parent.size_left+=i,t.parent.lf_left+=s),t=t.parent}function Ie(e,t){let i=0,s=0;if(t!==e.root){for(;t!==e.root&&t===t.parent.right;)t=t.parent;if(t!==e.root)for(i=we((t=t.parent).left)-t.size_left,s=Re(t.left)-t.lf_left,t.size_left+=i,t.lf_left+=s;t!==e.root&&(0!==i||0!==s);)t.parent.left===t&&(t.parent.size_left+=i,t.parent.lf_left+=s),t=t.parent}}be.parent=be,be.left=be,be.right=be,be.color=0;var Oe=i(43264);const De=65535;function Me(e){let t;return t=e[e.length-1]<65536?new Uint16Array(e.length):new Uint32Array(e.length),t.set(e,0),t}class Pe{constructor(e,t,i,s,n){this.lineStarts=e,this.cr=t,this.lf=i,this.crlf=s,this.isBasicASCII=n}}function Fe(e,t=!0){const i=[0];let s=1;for(let n=0,r=e.length;n(e!==be&&this._pieces.push(e.piece),!0)))}read(){return 0===this._pieces.length?0===this._index?(this._index++,this._BOM):null:this._index>this._pieces.length-1?null:0===this._index?this._BOM+this._tree.getPieceContent(this._pieces[this._index++]):this._tree.getPieceContent(this._pieces[this._index++])}}class We{constructor(e){this._limit=e,this._cache=[]}get(e){for(let t=this._cache.length-1;t>=0;t--){const i=this._cache[t];if(i.nodeStartOffset<=e&&i.nodeStartOffset+i.node.piece.length>=e)return i}return null}get2(e){for(let t=this._cache.length-1;t>=0;t--){const i=this._cache[t];if(i.nodeStartLineNumber&&i.nodeStartLineNumber=e)return i}return null}set(e){this._cache.length>=this._limit&&this._cache.shift(),this._cache.push(e)}validate(e){let t=!1;const i=this._cache;for(let s=0;s=e)&&(i[s]=null,t=!0)}if(t){const e=[];for(const t of i)null!==t&&e.push(t);this._cache=e}}}class Ve{constructor(e,t,i){this.create(e,t,i)}create(e,t,i){this._buffers=[new He("",[0])],this._lastChangeBufferPos={line:0,column:0},this.root=be,this._lineCnt=1,this._length=0,this._EOL=t,this._EOLLength=t.length,this._EOLNormalized=i;let s=null;for(let n=0,r=e.length;n0){e[n].lineStarts||(e[n].lineStarts=Fe(e[n].buffer));const t=new Ue(n+1,{line:0,column:0},{line:e[n].lineStarts.length-1,column:e[n].buffer.length-e[n].lineStarts[e[n].lineStarts.length-1]},e[n].lineStarts.length-1,e[n].buffer.length);this._buffers.push(e[n]),s=this.rbInsertRight(s,t)}this._searchCache=new We(1),this._lastVisitedLine={lineNumber:0,value:""},this.computeBufferMetadata()}normalizeEOL(e){const t=De,i=t-Math.floor(21845),s=2*i;let n="",r=0;const o=[];if(this.iterate(this.root,(t=>{const a=this.getNodeContent(t),c=a.length;if(r<=i||r+c0){const t=n.replace(/\r\n|\r|\n/g,e);o.push(new He(t,Fe(t)))}this.create(o,e,!0)}getEOL(){return this._EOL}setEOL(e){this._EOL=e,this._EOLLength=this._EOL.length,this.normalizeEOL(e)}createSnapshot(e){return new Be(this,e)}getOffsetAt(e,t){let i=0,s=this.root;for(;s!==be;)if(s.left!==be&&s.lf_left+1>=e)s=s.left;else{if(s.lf_left+s.piece.lineFeedCnt+1>=e){i+=s.size_left;return i+(this.getAccumulatedValue(s,e-s.lf_left-2)+t-1)}e-=s.lf_left+s.piece.lineFeedCnt,i+=s.size_left+s.piece.length,s=s.right}return i}getPositionAt(e){e=Math.floor(e),e=Math.max(0,e);let t=this.root,i=0;const s=e;for(;t!==be;)if(0!==t.size_left&&t.size_left>=e)t=t.left;else{if(t.size_left+t.piece.length>=e){const n=this.getIndexOf(t,e-t.size_left);if(i+=t.lf_left+n.index,0===n.index){const e=s-this.getOffsetAt(i+1,1);return new u.y(i+1,e+1)}return new u.y(i+1,n.remainder+1)}if(e-=t.size_left+t.piece.length,i+=t.lf_left+t.piece.lineFeedCnt,t.right===be){const t=s-e-this.getOffsetAt(i+1,1);return new u.y(i+1,t+1)}t=t.right}return new u.y(1,1)}getValueInRange(e,t){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return"";const i=this.nodeAt2(e.startLineNumber,e.startColumn),s=this.nodeAt2(e.endLineNumber,e.endColumn),n=this.getValueInRange2(i,s);return t?t===this._EOL&&this._EOLNormalized&&t===this.getEOL()&&this._EOLNormalized?n:n.replace(/\r\n|\r|\n/g,t):n}getValueInRange2(e,t){if(e.node===t.node){const i=e.node,s=this._buffers[i.piece.bufferIndex].buffer,n=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);return s.substring(n+e.remainder,n+t.remainder)}let i=e.node;const s=this._buffers[i.piece.bufferIndex].buffer,n=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);let r=s.substring(n+e.remainder,n+i.piece.length);for(i=i.next();i!==be;){const e=this._buffers[i.piece.bufferIndex].buffer,s=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);if(i===t.node){r+=e.substring(s,s+t.remainder);break}r+=e.substr(s,i.piece.length),i=i.next()}return r}getLinesContent(){const e=[];let t=0,i="",s=!1;return this.iterate(this.root,(n=>{if(n===be)return!0;const r=n.piece;let o=r.length;if(0===o)return!0;const a=this._buffers[r.bufferIndex].buffer,c=this._buffers[r.bufferIndex].lineStarts,l=r.start.line,h=r.end.line;let d=c[l]+r.start.column;if(s&&(10===a.charCodeAt(d)&&(d++,o--),e[t++]=i,i="",s=!1,0===o))return!0;if(l===h)return this._EOLNormalized||13!==a.charCodeAt(d+o-1)?i+=a.substr(d,o):(s=!0,i+=a.substr(d,o-1)),!0;i+=this._EOLNormalized?a.substring(d,Math.max(d,c[l+1]-this._EOLLength)):a.substring(d,c[l+1]).replace(/(\r\n|\r|\n)$/,""),e[t++]=i;for(let s=l+1;se+p,t.reset(0)):(v=d.buffer,C=e=>e,t.reset(p));do{if(f=t.next(v),f){if(C(f.index)>=m)return l;this.positionInBuffer(e,C(f.index)-u,_);const t=this.getLineFeedCnt(e.piece.bufferIndex,n,_),r=_.line===n.line?_.column-n.column+s:_.column+1,o=r+f[0].length;if(h[l++]=(0,Oe.dr)(new g.Q(i+t,r,i+t,o),f,a),C(f.index)+f[0].length>=m)return l;if(l>=c)return l}}while(f);return l}findMatchesLineByLine(e,t,i,s){const n=[];let r=0;const o=new Oe.W5(t.wordSeparators,t.regex);let a=this.nodeAt2(e.startLineNumber,e.startColumn);if(null===a)return[];const c=this.nodeAt2(e.endLineNumber,e.endColumn);if(null===c)return[];let l=this.positionInBuffer(a.node,a.remainder);const h=this.positionInBuffer(c.node,c.remainder);if(a.node===c.node)return this.findMatchesInNode(a.node,o,e.startLineNumber,e.startColumn,l,h,t,i,s,r,n),n;let d=e.startLineNumber,u=a.node;for(;u!==c.node;){const c=this.getLineFeedCnt(u.piece.bufferIndex,l,u.piece.end);if(c>=1){const a=this._buffers[u.piece.bufferIndex].lineStarts,h=this.offsetInBuffer(u.piece.bufferIndex,u.piece.start),g=a[l.line+c],p=d===e.startLineNumber?e.startColumn:1;if(r=this.findMatchesInNode(u,o,d,p,l,this.positionInBuffer(u,g-h),t,i,s,r,n),r>=s)return n;d+=c}const h=d===e.startLineNumber?e.startColumn-1:0;if(d===e.endLineNumber){const a=this.getLineContent(d).substring(h,e.endColumn-1);return r=this._findMatchesInLine(t,o,a,e.endLineNumber,h,r,n,i,s),n}if(r=this._findMatchesInLine(t,o,this.getLineContent(d).substr(h),d,h,r,n,i,s),r>=s)return n;d++,a=this.nodeAt2(d,1),u=a.node,l=this.positionInBuffer(a.node,a.remainder)}if(d===e.endLineNumber){const a=d===e.startLineNumber?e.startColumn-1:0,c=this.getLineContent(d).substring(a,e.endColumn-1);return r=this._findMatchesInLine(t,o,c,e.endLineNumber,a,r,n,i,s),n}const g=d===e.startLineNumber?e.startColumn:1;return r=this.findMatchesInNode(c.node,o,d,g,l,h,t,i,s,r,n),n}_findMatchesInLine(e,t,i,s,n,r,o,a,c){const l=e.wordSeparators;if(!a&&e.simpleSearch){const t=e.simpleSearch,a=t.length,h=i.length;let d=-a;for(;-1!==(d=i.indexOf(t,d+a));)if((!l||(0,Oe.wC)(l,i,h,d,a))&&(o[r++]=new v.Dg(new g.Q(s,d+1+n,s,d+1+a+n),null),r>=c))return r;return r}let h;t.reset(0);do{if(h=t.next(i),h&&(o[r++]=(0,Oe.dr)(new g.Q(s,h.index+1+n,s,h.index+1+h[0].length+n),h,a),r>=c))return r}while(h);return r}insert(e,t,i=!1){if(this._EOLNormalized=this._EOLNormalized&&i,this._lastVisitedLine.lineNumber=0,this._lastVisitedLine.value="",this.root!==be){const{node:i,remainder:s,nodeStartOffset:n}=this.nodeAt(e),r=i.piece,o=r.bufferIndex,a=this.positionInBuffer(i,s);if(0===i.piece.bufferIndex&&r.end.line===this._lastChangeBufferPos.line&&r.end.column===this._lastChangeBufferPos.column&&n+r.length===e&&t.lengthe){const e=[];let n=new Ue(r.bufferIndex,a,r.end,this.getLineFeedCnt(r.bufferIndex,a,r.end),this.offsetInBuffer(o,r.end)-this.offsetInBuffer(o,a));if(this.shouldCheckCRLF()&&this.endWithCR(t)){if(10===this.nodeCharCodeAt(i,s)){const e={line:n.start.line+1,column:0};n=new Ue(n.bufferIndex,e,n.end,this.getLineFeedCnt(n.bufferIndex,e,n.end),n.length-1),t+="\n"}}if(this.shouldCheckCRLF()&&this.startWithLF(t)){if(13===this.nodeCharCodeAt(i,s-1)){const n=this.positionInBuffer(i,s-1);this.deleteNodeTail(i,n),t="\r"+t,0===i.piece.length&&e.push(i)}else this.deleteNodeTail(i,a)}else this.deleteNodeTail(i,a);const c=this.createNewPieces(t);n.length>0&&this.rbInsertRight(i,n);let l=i;for(let t=0;t=0;r--)n=this.rbInsertLeft(n,s[r]);this.validateCRLFWithPrevNode(n),this.deleteNodes(i)}insertContentToNodeRight(e,t){this.adjustCarriageReturnFromNext(e,t)&&(e+="\n");const i=this.createNewPieces(e),s=this.rbInsertRight(t,i[0]);let n=s;for(let r=1;r=h))break;a=l+1}return i?(i.line=l,i.column=o-d,null):{line:l,column:o-d}}getLineFeedCnt(e,t,i){if(0===i.column)return i.line-t.line;const s=this._buffers[e].lineStarts;if(i.line===s.length-1)return i.line-t.line;const n=s[i.line+1],r=s[i.line]+i.column;if(n>r+1)return i.line-t.line;const o=r-1;return 13===this._buffers[e].buffer.charCodeAt(o)?i.line-t.line+1:i.line-t.line}offsetInBuffer(e,t){return this._buffers[e].lineStarts[t.line]+t.column}deleteNodes(e){for(let t=0;tDe){const t=[];for(;e.length>De;){const i=e.charCodeAt(65534);let s;13===i||i>=55296&&i<=56319?(s=e.substring(0,65534),e=e.substring(65534)):(s=e.substring(0,De),e=e.substring(De));const n=Fe(s);t.push(new Ue(this._buffers.length,{line:0,column:0},{line:n.length-1,column:s.length-n[n.length-1]},n.length-1,s.length)),this._buffers.push(new He(s,n))}const i=Fe(e);return t.push(new Ue(this._buffers.length,{line:0,column:0},{line:i.length-1,column:e.length-i[i.length-1]},i.length-1,e.length)),this._buffers.push(new He(e,i)),t}let t=this._buffers[0].buffer.length;const i=Fe(e,!1);let s=this._lastChangeBufferPos;if(this._buffers[0].lineStarts[this._buffers[0].lineStarts.length-1]===t&&0!==t&&this.startWithLF(e)&&this.endWithCR(this._buffers[0].buffer)){this._lastChangeBufferPos={line:this._lastChangeBufferPos.line,column:this._lastChangeBufferPos.column+1},s=this._lastChangeBufferPos;for(let e=0;e=e-1)i=i.left;else{if(i.lf_left+i.piece.lineFeedCnt>e-1){const s=this.getAccumulatedValue(i,e-i.lf_left-2),o=this.getAccumulatedValue(i,e-i.lf_left-1),a=this._buffers[i.piece.bufferIndex].buffer,c=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);return n+=i.size_left,this._searchCache.set({node:i,nodeStartOffset:n,nodeStartLineNumber:r-(e-1-i.lf_left)}),a.substring(c+s,c+o-t)}if(i.lf_left+i.piece.lineFeedCnt===e-1){const t=this.getAccumulatedValue(i,e-i.lf_left-2),n=this._buffers[i.piece.bufferIndex].buffer,r=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);s=n.substring(r+t,r+i.piece.length);break}e-=i.lf_left+i.piece.lineFeedCnt,n+=i.size_left+i.piece.length,i=i.right}}for(i=i.next();i!==be;){const e=this._buffers[i.piece.bufferIndex].buffer;if(i.piece.lineFeedCnt>0){const n=this.getAccumulatedValue(i,0),r=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);return s+=e.substring(r,r+n-t),s}{const t=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);s+=e.substr(t,i.piece.length)}i=i.next()}return s}computeBufferMetadata(){let e=this.root,t=1,i=0;for(;e!==be;)t+=e.lf_left+e.piece.lineFeedCnt,i+=e.size_left+e.piece.length,e=e.right;this._lineCnt=t,this._length=i,this._searchCache.validate(this._length)}getIndexOf(e,t){const i=e.piece,s=this.positionInBuffer(e,t),n=s.line-i.start.line;if(this.offsetInBuffer(i.bufferIndex,i.end)-this.offsetInBuffer(i.bufferIndex,i.start)===t){const t=this.getLineFeedCnt(e.piece.bufferIndex,i.start,s);if(t!==n)return{index:t,remainder:0}}return{index:n,remainder:s.column}}getAccumulatedValue(e,t){if(t<0)return 0;const i=e.piece,s=this._buffers[i.bufferIndex].lineStarts,n=i.start.line+t+1;return n>i.end.line?s[i.end.line]+i.end.column-s[i.start.line]-i.start.column:s[n]-s[i.start.line]-i.start.column}deleteNodeTail(e,t){const i=e.piece,s=i.lineFeedCnt,n=this.offsetInBuffer(i.bufferIndex,i.end),r=t,o=this.offsetInBuffer(i.bufferIndex,r),a=this.getLineFeedCnt(i.bufferIndex,i.start,r),c=a-s,l=o-n,h=i.length+l;e.piece=new Ue(i.bufferIndex,i.start,r,a,h),Ne(this,e,l,c)}deleteNodeHead(e,t){const i=e.piece,s=i.lineFeedCnt,n=this.offsetInBuffer(i.bufferIndex,i.start),r=t,o=this.getLineFeedCnt(i.bufferIndex,r,i.end),a=o-s,c=n-this.offsetInBuffer(i.bufferIndex,r),l=i.length+c;e.piece=new Ue(i.bufferIndex,r,i.end,o,l),Ne(this,e,c,a)}shrinkNode(e,t,i){const s=e.piece,n=s.start,r=s.end,o=s.length,a=s.lineFeedCnt,c=t,l=this.getLineFeedCnt(s.bufferIndex,s.start,c),h=this.offsetInBuffer(s.bufferIndex,t)-this.offsetInBuffer(s.bufferIndex,n);e.piece=new Ue(s.bufferIndex,s.start,c,l,h),Ne(this,e,h-o,l-a);const d=new Ue(s.bufferIndex,i,r,this.getLineFeedCnt(s.bufferIndex,i,r),this.offsetInBuffer(s.bufferIndex,r)-this.offsetInBuffer(s.bufferIndex,i)),u=this.rbInsertRight(e,d);this.validateCRLFWithPrevNode(u)}appendToNode(e,t){this.adjustCarriageReturnFromNext(t,e)&&(t+="\n");const i=this.shouldCheckCRLF()&&this.startWithLF(t)&&this.endWithCR(e),s=this._buffers[0].buffer.length;this._buffers[0].buffer+=t;const n=Fe(t,!1);for(let d=0;de)t=t.left;else{if(t.size_left+t.piece.length>=e){s+=t.size_left;const i={node:t,remainder:e-t.size_left,nodeStartOffset:s};return this._searchCache.set(i),i}e-=t.size_left+t.piece.length,s+=t.size_left+t.piece.length,t=t.right}return null}nodeAt2(e,t){let i=this.root,s=0;for(;i!==be;)if(i.left!==be&&i.lf_left>=e-1)i=i.left;else{if(i.lf_left+i.piece.lineFeedCnt>e-1){const n=this.getAccumulatedValue(i,e-i.lf_left-2),r=this.getAccumulatedValue(i,e-i.lf_left-1);return s+=i.size_left,{node:i,remainder:Math.min(n+t-1,r),nodeStartOffset:s}}if(i.lf_left+i.piece.lineFeedCnt===e-1){const n=this.getAccumulatedValue(i,e-i.lf_left-2);if(n+t-1<=i.piece.length)return{node:i,remainder:n+t-1,nodeStartOffset:s};t-=i.piece.length-n;break}e-=i.lf_left+i.piece.lineFeedCnt,s+=i.size_left+i.piece.length,i=i.right}for(i=i.next();i!==be;){if(i.piece.lineFeedCnt>0){const e=this.getAccumulatedValue(i,0),s=this.offsetOfNode(i);return{node:i,remainder:Math.min(t-1,e),nodeStartOffset:s}}if(i.piece.length>=t-1){return{node:i,remainder:t-1,nodeStartOffset:this.offsetOfNode(i)}}t-=i.piece.length,i=i.next()}return null}nodeCharCodeAt(e,t){if(e.piece.lineFeedCnt<1)return-1;const i=this._buffers[e.piece.bufferIndex],s=this.offsetInBuffer(e.piece.bufferIndex,e.piece.start)+t;return i.buffer.charCodeAt(s)}offsetOfNode(e){if(!e)return 0;let t=e.size_left;for(;e!==this.root;)e.parent.right===e&&(t+=e.parent.size_left+e.parent.piece.length),e=e.parent;return t}shouldCheckCRLF(){return!(this._EOLNormalized&&"\n"===this._EOL)}startWithLF(e){if("string"===typeof e)return 10===e.charCodeAt(0);if(e===be||0===e.piece.lineFeedCnt)return!1;const t=e.piece,i=this._buffers[t.bufferIndex].lineStarts,s=t.start.line,n=i[s]+t.start.column;if(s===i.length-1)return!1;return!(i[s+1]>n+1)&&10===this._buffers[t.bufferIndex].buffer.charCodeAt(n)}endWithCR(e){return"string"===typeof e?13===e.charCodeAt(e.length-1):e!==be&&0!==e.piece.lineFeedCnt&&13===this.nodeCharCodeAt(e,e.piece.length-1)}validateCRLFWithPrevNode(e){if(this.shouldCheckCRLF()&&this.startWithLF(e)){const t=e.prev();this.endWithCR(t)&&this.fixCRLF(t,e)}}validateCRLFWithNextNode(e){if(this.shouldCheckCRLF()&&this.endWithCR(e)){const t=e.next();this.startWithLF(t)&&this.fixCRLF(e,t)}}fixCRLF(e,t){const i=[],s=this._buffers[e.piece.bufferIndex].lineStarts;let n;n=0===e.piece.end.column?{line:e.piece.end.line-1,column:s[e.piece.end.line]-s[e.piece.end.line-1]-1}:{line:e.piece.end.line,column:e.piece.end.column-1};const r=e.piece.length-1,o=e.piece.lineFeedCnt-1;e.piece=new Ue(e.piece.bufferIndex,e.piece.start,n,o,r),Ne(this,e,-1,-1),0===e.piece.length&&i.push(e);const a={line:t.piece.start.line+1,column:0},c=t.piece.length-1,l=this.getLineFeedCnt(t.piece.bufferIndex,a,t.piece.end);t.piece=new Ue(t.piece.bufferIndex,a,t.piece.end,l,c),Ne(this,t,-1,-1),0===t.piece.length&&i.push(t);const h=this.createNewPieces("\r\n");this.rbInsertRight(e,h[0]);for(let d=0;de.sortIndex-t.sortIndex))}this._mightContainRTL=s,this._mightContainUnusualLineTerminators=n,this._mightContainNonBasicASCII=r;const p=this._doApplyEdits(a);let m=null;if(t&&u.length>0){u.sort(((e,t)=>t.lineNumber-e.lineNumber)),m=[];for(let e=0,t=u.length;e0&&u[e-1].lineNumber===t)continue;const i=u[e].oldContent,s=this.getLineContent(t);0!==s.length&&s!==i&&-1===c.HG(s)&&m.push(t)}}return this._onDidChangeContent.fire(),new v.F4(g,p,m)}_reduceOperations(e){return e.length<1e3?e:[this._toSingleEditOperation(e)]}_toSingleEditOperation(e){let t=!1;const i=e[0].range,s=e[e.length-1].range,n=new g.Q(i.startLineNumber,i.startColumn,s.endLineNumber,s.endColumn);let r=i.startLineNumber,o=i.startColumn;const a=[];for(let h=0,p=e.length;h0&&a.push(i.text),r=s.endLineNumber,o=s.endColumn}const c=a.join(""),[l,d,u]=(0,h.W)(c);return{sortIndex:0,identifier:e[0].identifier,range:n,rangeOffset:this.getOffsetAt(n.startLineNumber,n.startColumn),rangeLength:this.getValueLengthInRange(n,0),text:c,eolCount:l,firstLineLength:d,lastLineLength:u,forceMoveMarkers:t,isAutoWhitespaceEdit:!1}}_doApplyEdits(e){e.sort(Ge._sortOpsDescending);const t=[];for(let i=0;i0){const e=o.eolCount+1;l=1===e?new g.Q(a,c,a,c+o.firstLineLength):new g.Q(a,c,a+e-1,o.lastLineLength+1)}else l=new g.Q(a,c,a,c);i=l.endLineNumber,s=l.endColumn,t.push(l),n=o}return t}static _sortOpsAscending(e,t){const i=g.Q.compareRangesUsingEnds(e.range,t.range);return 0===i?e.sortIndex-t.sortIndex:i}static _sortOpsDescending(e,t){const i=g.Q.compareRangesUsingEnds(e.range,t.range);return 0===i?t.sortIndex-e.sortIndex:-i}}class je{constructor(e,t,i,s,n,r,o,a,c){this._chunks=e,this._bom=t,this._cr=i,this._lf=s,this._crlf=n,this._containsRTL=r,this._containsUnusualLineTerminators=o,this._isBasicASCII=a,this._normalizeEOL=c}_getEOL(e){const t=this._cr+this._lf+this._crlf,i=this._cr+this._crlf;return 0===t?1===e?"\n":"\r\n":i>t/2?"\r\n":"\n"}create(e){const t=this._getEOL(e),i=this._chunks;if(this._normalizeEOL&&("\r\n"===t&&(this._cr>0||this._lf>0)||"\n"===t&&(this._cr>0||this._crlf>0)))for(let n=0,r=i.length;n=55296&&t<=56319?(this._acceptChunk1(e.substr(0,e.length-1),!1),this._hasPreviousChar=!0,this._previousChar=t):(this._acceptChunk1(e,!1),this._hasPreviousChar=!1,this._previousChar=t)}_acceptChunk1(e,t){(t||0!==e.length)&&(this._hasPreviousChar?this._acceptChunk2(String.fromCharCode(this._previousChar)+e):this._acceptChunk2(e))}_acceptChunk2(e){const t=function(e,t){e.length=0,e[0]=0;let i=1,s=0,n=0,r=0,o=!0;for(let c=0,l=t.length;c126)&&(o=!1)}const a=new Pe(Me(e),s,n,r,o);return e.length=0,a}(this._tmpLineStarts,e);this.chunks.push(new He(e,t.lineStarts)),this.cr+=t.cr,this.lf+=t.lf,this.crlf+=t.crlf,t.isBasicASCII||(this.isBasicASCII=!1,this.containsRTL||(this.containsRTL=c.E_(e)),this.containsUnusualLineTerminators||(this.containsUnusualLineTerminators=c.$X(e)))}finish(e=!0){return this._finish(),new je(this.chunks,this.BOM,this.cr,this.lf,this.crlf,this.containsRTL,this.containsUnusualLineTerminators,this.isBasicASCII,e)}_finish(){if(0===this.chunks.length&&this._acceptChunk1("",!0),this._hasPreviousChar){this._hasPreviousChar=!1;const e=this.chunks[this.chunks.length-1];e.buffer+=String.fromCharCode(this._previousChar);const t=Fe(e.buffer);e.lineStarts=t,13===this._previousChar&&this.cr++}}}var Ye=i(86571),qe=i(26486),$e=i(62083),Qe=i(20761),Xe=i(90766),Ze=i(98067),Je=i(78381),et=i(74444),tt=i(20788);class it{constructor(e){this._default=e,this._store=[]}get(e){return e=this._store.length;)this._store[this._store.length]=this._default;this._store[e]=t}replace(e,t,i){if(e>=this._store.length)return;if(0===t)return void this.insert(e,i);if(0===i)return void this.delete(e,t);const s=this._store.slice(0,e),n=this._store.slice(e+t),r=function(e,t){const i=[];for(let s=0;s=this._store.length||this._store.splice(e,t)}insert(e,t){if(0===t||e>=this._store.length)return;const i=[];for(let s=0;s0){const i=this._tokens[this._tokens.length-1];if(i.endLineNumber+1===e)return void i.appendLineTokens(t)}this._tokens.push(new st(e,[t]))}finalize(){return this._tokens}}var rt=i(87469);class ot{constructor(e,t){this.tokenizationSupport=t,this.initialState=this.tokenizationSupport.getInitialState(),this.store=new ct(e)}getStartState(e){return this.store.getStartState(e,this.initialState)}getFirstInvalidLine(){return this.store.getFirstInvalidLine(this.initialState)}}class at extends ot{constructor(e,t,i,s){super(e,t),this._textModel=i,this._languageIdCodec=s}updateTokensUntilLine(e,t){const i=this._textModel.getLanguageId();for(;;){const s=this.getFirstInvalidLine();if(!s||s.lineNumber>t)break;const n=this._textModel.getLineContent(s.lineNumber),r=dt(this._languageIdCodec,i,this.tokenizationSupport,n,!0,s.startState);e.add(s.lineNumber,r.tokens),this.store.setEndState(s.lineNumber,r.endState)}}getTokenTypeIfInsertingCharacter(e,t){const i=this.getStartState(e.lineNumber);if(!i)return 0;const s=this._textModel.getLanguageId(),n=this._textModel.getLineContent(e.lineNumber),r=n.substring(0,e.column-1)+t+n.substring(e.column-1),o=dt(this._languageIdCodec,s,this.tokenizationSupport,r,!0,i),a=new rt.f(o.tokens,r,this._languageIdCodec);if(0===a.getCount())return 0;const c=a.findTokenIndexAtOffset(e.column-1);return a.getStandardTokenType(c)}tokenizeLineWithEdit(e,t,i){const s=e.lineNumber,n=e.column,r=this.getStartState(s);if(!r)return null;const o=this._textModel.getLineContent(s),a=o.substring(0,n-1)+i+o.substring(n-1+t),c=this._textModel.getLanguageIdAtPosition(s,0),l=dt(this._languageIdCodec,c,this.tokenizationSupport,a,!0,r);return new rt.f(l.tokens,a,this._languageIdCodec)}hasAccurateTokensForLine(e){return e1&&o>=1;o--){const e=this._textModel.getLineFirstNonWhitespaceColumn(o);if(0!==e&&(e0&&i>0&&(i--,t--),this._lineEndStates.replace(e.startLineNumber,i,t)}}class ht{constructor(){this._ranges=[]}get min(){return 0===this._ranges.length?null:this._ranges[0].start}delete(e){const t=this._ranges.findIndex((t=>t.contains(e)));if(-1!==t){const i=this._ranges[t];i.start===e?i.endExclusive===e+1?this._ranges.splice(t,1):this._ranges[t]=new et.L(e+1,i.endExclusive):i.endExclusive===e+1?this._ranges[t]=new et.L(i.start,e):this._ranges.splice(t,1,new et.L(i.start,e),new et.L(e+1,i.endExclusive))}}addRange(e){et.L.addRange(e,this._ranges)}addRangeAndResize(e,t){let i=0;for(;!(i>=this._ranges.length||e.start<=this._ranges[i].endExclusive);)i++;let s=i;for(;!(s>=this._ranges.length||e.endExclusivee.toString())).join(" + ")}}function dt(e,t,i,s,n,o){let a=null;if(i)try{a=i.tokenizeEncoded(s,n,o.clone())}catch(c){(0,r.dz)(c)}return a||(a=(0,tt.Lh)(e.encodeLanguageId(t),o)),rt.f.convertToEndOffset(a.tokens,s.length),a}class ut{constructor(e,t){this._tokenizerWithStateStore=e,this._backgroundTokenStore=t,this._isDisposed=!1,this._isScheduled=!1}dispose(){this._isDisposed=!0}handleChanges(){this._beginBackgroundTokenization()}_beginBackgroundTokenization(){!this._isScheduled&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._isScheduled=!0,(0,Xe.$6)((e=>{this._isScheduled=!1,this._backgroundTokenizeWithDeadline(e)})))}_backgroundTokenizeWithDeadline(e){const t=Date.now()+e.timeRemaining(),i=()=>{!this._isDisposed&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._backgroundTokenizeForAtLeast1ms(),Date.now()1)break;if(this._tokenizeOneInvalidLine(t)>=e)break}while(this._hasLinesToTokenize());this._backgroundTokenStore.setTokens(t.finalize()),this.checkFinished()}_hasLinesToTokenize(){return!!this._tokenizerWithStateStore&&!this._tokenizerWithStateStore.store.allStatesValid()}_tokenizeOneInvalidLine(e){const t=this._tokenizerWithStateStore?.getFirstInvalidLine();return t?(this._tokenizerWithStateStore.updateTokensUntilLine(e,t.lineNumber),t.lineNumber):this._tokenizerWithStateStore._textModel.getLineCount()+1}checkFinished(){this._isDisposed||this._tokenizerWithStateStore.store.allStatesValid()&&this._backgroundTokenStore.backgroundTokenizationFinished()}requestTokens(e,t){this._tokenizerWithStateStore.store.invalidateEndStateRange(new Ye.M(e,t))}}class gt{constructor(){this._onDidChangeVisibleRanges=new o.vl,this.onDidChangeVisibleRanges=this._onDidChangeVisibleRanges.event,this._views=new Set}attachView(){const e=new pt((t=>{this._onDidChangeVisibleRanges.fire({view:e,state:t})}));return this._views.add(e),e}detachView(e){this._views.delete(e),this._onDidChangeVisibleRanges.fire({view:e,state:void 0})}}class pt{constructor(e){this.handleStateChange=e}setVisibleLines(e,t){const i=e.map((e=>new Ye.M(e.startLineNumber,e.endLineNumber+1)));this.handleStateChange({visibleLineRanges:i,stabilized:t})}}class mt extends a.jG{get lineRanges(){return this._lineRanges}constructor(e){super(),this._refreshTokens=e,this.runner=this._register(new Xe.uC((()=>this.update()),50)),this._computedLineRanges=[],this._lineRanges=[]}update(){(0,s.aI)(this._computedLineRanges,this._lineRanges,((e,t)=>e.equals(t)))||(this._computedLineRanges=this._lineRanges,this._refreshTokens())}handleStateChange(e){this._lineRanges=e.visibleLineRanges,e.stabilized?(this.runner.cancel(),this.update()):this.runner.schedule()}}class ft extends a.jG{get backgroundTokenizationState(){return this._backgroundTokenizationState}constructor(e,t,i){super(),this._languageIdCodec=e,this._textModel=t,this.getLanguageId=i,this._backgroundTokenizationState=1,this._onDidChangeBackgroundTokenizationState=this._register(new o.vl),this.onDidChangeBackgroundTokenizationState=this._onDidChangeBackgroundTokenizationState.event,this._onDidChangeTokens=this._register(new o.vl),this.onDidChangeTokens=this._onDidChangeTokens.event}tokenizeIfCheap(e){this.isCheapToTokenize(e)&&this.forceTokenization(e)}}class _t extends ft{constructor(e,t,i,s){super(t,i,s),this._treeSitterService=e,this._tokenizationSupport=null,this._initialize()}_initialize(){const e=this.getLanguageId();this._tokenizationSupport&&this._lastLanguageId===e||(this._lastLanguageId=e,this._tokenizationSupport=$e.OB.get(e))}getLineTokens(e){const t=this._textModel.getLineContent(e);if(this._tokenizationSupport){const i=this._tokenizationSupport.tokenizeEncoded(e,this._textModel);if(i)return new rt.f(i,t,this._languageIdCodec)}return rt.f.createEmpty(t,this._languageIdCodec)}resetTokenization(e=!0){e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]}),this._initialize()}handleDidChangeAttached(){}handleDidChangeContent(e){e.isFlush&&this.resetTokenization(!1)}forceTokenization(e){}hasAccurateTokensForLine(e){return!0}isCheapToTokenize(e){return!0}getTokenTypeIfInsertingCharacter(e,t,i){return 0}tokenizeLineWithEdit(e,t,i){return null}get hasTokens(){return void 0!==this._treeSitterService.getParseResult(this._textModel)}}var vt=i(44432);const Ct=new Uint32Array(0).buffer;class Et{static deleteBeginning(e,t){return null===e||e===Ct?e:Et.delete(e,0,t)}static deleteEnding(e,t){if(null===e||e===Ct)return e;const i=bt(e),s=i[i.length-2];return Et.delete(e,t,s)}static delete(e,t,i){if(null===e||e===Ct||t===i)return e;const s=bt(e),n=s.length>>>1;if(0===t&&s[s.length-2]===i)return Ct;const r=rt.f.findIndexInTokensArray(s,t),o=r>0?s[r-1<<1]:0;if(ic&&(s[a++]=e,s[a++]=s[1+(d<<1)],c=e)}if(a===s.length)return e;const h=new Uint32Array(a);return h.set(s.subarray(0,a),0),h.buffer}static append(e,t){if(t===Ct)return e;if(e===Ct)return t;if(null===e)return e;if(null===t)return null;const i=bt(e),s=bt(t),n=s.length>>>1,r=new Uint32Array(i.length+s.length);r.set(i,0);let o=i.length;const a=i[i.length-2];for(let c=0;c>>1;let r=rt.f.findIndexInTokensArray(s,t);if(r>0){s[r-1<<1]===t&&r--}for(let o=r;o0}getTokens(e,t,i){let s=null;if(t1&&(t=St.x.getLanguageId(s[1])!==e),!t)return Ct}if(!s||0===s.length){const i=new Uint32Array(2);return i[0]=t,i[1]=wt(e),i.buffer}return s[s.length-2]=t,0===s.byteOffset&&s.byteLength===s.buffer.byteLength?s.buffer:s}_ensureLine(e){for(;e>=this._len;)this._lineTokens[this._len]=null,this._len++}_deleteLines(e,t){0!==t&&(e+t>this._len&&(t=this._len-e),this._lineTokens.splice(e,t),this._len-=t)}_insertLines(e,t){if(0===t)return;const i=[];for(let s=0;s=this._len)return;if(e.startLineNumber===e.endLineNumber){if(e.startColumn===e.endColumn)return;return void(this._lineTokens[t]=Et.delete(this._lineTokens[t],e.startColumn-1,e.endColumn-1))}this._lineTokens[t]=Et.deleteEnding(this._lineTokens[t],e.startColumn-1);const i=e.endLineNumber-1;let s=null;i=this._len||(0!==t?(this._lineTokens[s]=Et.deleteEnding(this._lineTokens[s],e.column-1),this._lineTokens[s]=Et.insert(this._lineTokens[s],e.column-1,i),this._insertLines(e.lineNumber,t)):this._lineTokens[s]=Et.insert(this._lineTokens[s],e.column-1,i))}setMultilineTokens(e,t){if(0===e.length)return{changes:[]};const i=[];for(let s=0,n=e.length;s>>0}class Rt{constructor(e){this._pieces=[],this._isComplete=!1,this._languageIdCodec=e}flush(){this._pieces=[],this._isComplete=!1}isEmpty(){return 0===this._pieces.length}set(e,t){this._pieces=e||[],this._isComplete=t}setPartial(e,t){let i=e;if(t.length>0){const s=t[0].getRange(),n=t[t.length-1].getRange();if(!s||!n)return e;i=e.plusRange(s).plusRange(n)}let n=null;for(let s=0,r=this._pieces.length;si.endLineNumber){n=n||{index:s};break}if(e.removeTokens(i),e.isEmpty()){this._pieces.splice(s,1),s--,r--;continue}if(e.endLineNumberi.endLineNumber){n=n||{index:s};continue}const[t,o]=e.split(i);t.isEmpty()?n=n||{index:s}:o.isEmpty()||(this._pieces.splice(s,1,t,o),s++,r++,n=n||{index:s})}return n=n||{index:this._pieces.length},t.length>0&&(this._pieces=s.nK(this._pieces,n.index,t)),i}isComplete(){return this._isComplete}addSparseTokens(e,t){if(0===t.getLineContent().length)return t;const i=this._pieces;if(0===i.length)return t;const s=i[Rt._findFirstPieceWithLine(i,e)].getLineTokens(e);if(!s)return t;const n=t.getCount(),r=s.getCount();let o=0;const a=[];let c=0,l=0;const h=(e,t)=>{e!==l&&(l=e,a[c++]=e,a[c++]=t)};for(let d=0;d>>0,c=~a>>>0;for(;ot)){for(;n>i&&e[n-1].startLineNumber<=t&&t<=e[n-1].endLineNumber;)n--;return n}s=n-1}}return i}acceptEdit(e,t,i,s,n){for(const r of this._pieces)r.acceptEdit(e,t,i,s,n)}}var Lt,Tt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xt=function(e,t){return function(i,s){t(i,s,e)}};let kt=Lt=class extends Qe._{constructor(e,t,i,s,n,r,c){super(),this._textModel=e,this._bracketPairsTextModelPart=t,this._languageId=i,this._attachedViews=s,this._languageService=n,this._languageConfigurationService=r,this._treeSitterService=c,this._semanticTokens=new Rt(this._languageService.languageIdCodec),this._onDidChangeLanguage=this._register(new o.vl),this.onDidChangeLanguage=this._onDidChangeLanguage.event,this._onDidChangeLanguageConfiguration=this._register(new o.vl),this.onDidChangeLanguageConfiguration=this._onDidChangeLanguageConfiguration.event,this._onDidChangeTokens=this._register(new o.vl),this.onDidChangeTokens=this._onDidChangeTokens.event,this._tokensDisposables=this._register(new a.Cm),this._register(this._languageConfigurationService.onDidChange((e=>{e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}))),this._register(o.Jh.filter($e.OB.onDidChange,(e=>e.changedLanguages.includes(this._languageId)))((()=>{this.createPreferredTokenProvider()}))),this.createPreferredTokenProvider()}createGrammarTokens(){return this._register(new At(this._languageService.languageIdCodec,this._textModel,(()=>this._languageId),this._attachedViews))}createTreeSitterTokens(){return this._register(new _t(this._treeSitterService,this._languageService.languageIdCodec,this._textModel,(()=>this._languageId)))}createTokens(e){const t=void 0!==this._tokens;this._tokens?.dispose(),this._tokens=e?this.createTreeSitterTokens():this.createGrammarTokens(),this._tokensDisposables.clear(),this._tokensDisposables.add(this._tokens.onDidChangeTokens((e=>{this._emitModelTokensChangedEvent(e)}))),this._tokensDisposables.add(this._tokens.onDidChangeBackgroundTokenizationState((e=>{this._bracketPairsTextModelPart.handleDidChangeBackgroundTokenizationState()}))),t&&this._tokens.resetTokenization()}createPreferredTokenProvider(){$e.OB.get(this._languageId)?this._tokens instanceof _t||this.createTokens(!0):this._tokens instanceof At||this.createTokens(!1)}handleLanguageConfigurationServiceChange(e){e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}handleDidChangeContent(e){if(e.isFlush)this._semanticTokens.flush();else if(!e.isEolChange)for(const t of e.changes){const[e,i,s]=(0,h.W)(t.text);this._semanticTokens.acceptEdit(t.range,e,i,s,t.text.length>0?t.text.charCodeAt(0):0)}this._tokens.handleDidChangeContent(e)}handleDidChangeAttached(){this._tokens.handleDidChangeAttached()}getLineTokens(e){this.validateLineNumber(e);const t=this._tokens.getLineTokens(e);return this._semanticTokens.addSparseTokens(e,t)}_emitModelTokensChangedEvent(e){this._textModel._isDisposing()||(this._bracketPairsTextModelPart.handleDidChangeTokens(e),this._onDidChangeTokens.fire(e))}validateLineNumber(e){if(e<1||e>this._textModel.getLineCount())throw new r.D7("Illegal value for lineNumber")}get hasTokens(){return this._tokens.hasTokens}resetTokenization(){this._tokens.resetTokenization()}get backgroundTokenizationState(){return this._tokens.backgroundTokenizationState}forceTokenization(e){this.validateLineNumber(e),this._tokens.forceTokenization(e)}hasAccurateTokensForLine(e){return this.validateLineNumber(e),this._tokens.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return this.validateLineNumber(e),this._tokens.isCheapToTokenize(e)}tokenizeIfCheap(e){this.validateLineNumber(e),this._tokens.tokenizeIfCheap(e)}getTokenTypeIfInsertingCharacter(e,t,i){return this._tokens.getTokenTypeIfInsertingCharacter(e,t,i)}tokenizeLineWithEdit(e,t,i){return this._tokens.tokenizeLineWithEdit(e,t,i)}setSemanticTokens(e,t){this._semanticTokens.set(e,t),this._emitModelTokensChangedEvent({semanticTokensApplied:null!==e,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]})}hasCompleteSemanticTokens(){return this._semanticTokens.isComplete()}hasSomeSemanticTokens(){return!this._semanticTokens.isEmpty()}setPartialSemanticTokens(e,t){if(this.hasCompleteSemanticTokens())return;const i=this._textModel.validateRange(this._semanticTokens.setPartial(e,t));this._emitModelTokensChangedEvent({semanticTokensApplied:!0,ranges:[{fromLineNumber:i.startLineNumber,toLineNumber:i.endLineNumber}]})}getWordAtPosition(e){this.assertNotDisposed();const t=this._textModel.validatePosition(e),i=this._textModel.getLineContent(t.lineNumber),s=this.getLineTokens(t.lineNumber),n=s.findTokenIndexAtOffset(t.column-1),[r,o]=Lt._findLanguageBoundaries(s,n),a=(0,qe.Th)(t.column,this.getLanguageConfiguration(s.getLanguageId(n)).getWordDefinition(),i.substring(r,o),r);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a;if(n>0&&r===t.column-1){const[r,o]=Lt._findLanguageBoundaries(s,n-1),a=(0,qe.Th)(t.column,this.getLanguageConfiguration(s.getLanguageId(n-1)).getWordDefinition(),i.substring(r,o),r);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a}return null}getLanguageConfiguration(e){return this._languageConfigurationService.getLanguageConfiguration(e)}static _findLanguageBoundaries(e,t){const i=e.getLanguageId(t);let s=0;for(let r=t;r>=0&&e.getLanguageId(r)===i;r--)s=e.getStartOffset(r);let n=e.getLineContent().length;for(let r=t,o=e.getCount();r{const t=this.getLanguageId();-1!==e.changedLanguages.indexOf(t)&&this.resetTokenization()}))),this.resetTokenization(),this._register(s.onDidChangeVisibleRanges((({view:e,state:t})=>{if(t){let i=this._attachedViewStates.get(e);i||(i=new mt((()=>this.refreshRanges(i.lineRanges))),this._attachedViewStates.set(e,i)),i.handleStateChange(t)}else this._attachedViewStates.deleteAndDispose(e)})))}resetTokenization(e=!0){this._tokens.flush(),this._debugBackgroundTokens?.flush(),this._debugBackgroundStates&&(this._debugBackgroundStates=new ct(this._textModel.getLineCount())),e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]});const[t,i]=(()=>{if(this._textModel.isTooLargeForTokenization())return[null,null];const e=$e.dG.get(this.getLanguageId());if(!e)return[null,null];let t;try{t=e.getInitialState()}catch(i){return(0,r.dz)(i),[null,null]}return[e,t]})();if(this._tokenizer=t&&i?new at(this._textModel.getLineCount(),t,this._textModel,this._languageIdCodec):null,this._backgroundTokenizer.clear(),this._defaultBackgroundTokenizer=null,this._tokenizer){const e={setTokens:e=>{this.setTokens(e)},backgroundTokenizationFinished:()=>{if(2===this._backgroundTokenizationState)return;this._backgroundTokenizationState=2,this._onDidChangeBackgroundTokenizationState.fire()},setEndState:(e,t)=>{if(!this._tokenizer)return;const i=this._tokenizer.store.getFirstInvalidEndStateLineNumber();null!==i&&e>=i&&this._tokenizer?.store.setEndState(e,t)}};t&&t.createBackgroundTokenizer&&!t.backgroundTokenizerShouldOnlyVerifyTokens&&(this._backgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,e)),this._backgroundTokenizer.value||this._textModel.isTooLargeForTokenization()||(this._backgroundTokenizer.value=this._defaultBackgroundTokenizer=new ut(this._tokenizer,e),this._defaultBackgroundTokenizer.handleChanges()),t?.backgroundTokenizerShouldOnlyVerifyTokens&&t.createBackgroundTokenizer?(this._debugBackgroundTokens=new yt(this._languageIdCodec),this._debugBackgroundStates=new ct(this._textModel.getLineCount()),this._debugBackgroundTokenizer.clear(),this._debugBackgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,{setTokens:e=>{this._debugBackgroundTokens?.setMultilineTokens(e,this._textModel)},backgroundTokenizationFinished(){},setEndState:(e,t)=>{this._debugBackgroundStates?.setEndState(e,t)}})):(this._debugBackgroundTokens=void 0,this._debugBackgroundStates=void 0,this._debugBackgroundTokenizer.value=void 0)}this.refreshAllVisibleLineTokens()}handleDidChangeAttached(){this._defaultBackgroundTokenizer?.handleChanges()}handleDidChangeContent(e){if(e.isFlush)this.resetTokenization(!1);else if(!e.isEolChange){for(const t of e.changes){const[e,i]=(0,h.W)(t.text);this._tokens.acceptEdit(t.range,e,i),this._debugBackgroundTokens?.acceptEdit(t.range,e,i)}this._debugBackgroundStates?.acceptChanges(e.changes),this._tokenizer&&this._tokenizer.store.acceptChanges(e.changes),this._defaultBackgroundTokenizer?.handleChanges()}}setTokens(e){const{changes:t}=this._tokens.setMultilineTokens(e,this._textModel);return t.length>0&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:t}),{changes:t}}refreshAllVisibleLineTokens(){const e=Ye.M.joinMany([...this._attachedViewStates].map((([e,t])=>t.lineRanges)));this.refreshRanges(e)}refreshRanges(e){for(const t of e)this.refreshRange(t.startLineNumber,t.endLineNumberExclusive-1)}refreshRange(e,t){if(!this._tokenizer)return;e=Math.max(1,Math.min(this._textModel.getLineCount(),e)),t=Math.min(this._textModel.getLineCount(),t);const i=new nt,{heuristicTokens:s}=this._tokenizer.tokenizeHeuristically(i,e,t),n=this.setTokens(i.finalize());if(s)for(const r of n.changes)this._backgroundTokenizer.value?.requestTokens(r.fromLineNumber,r.toLineNumber+1);this._defaultBackgroundTokenizer?.checkFinished()}forceTokenization(e){const t=new nt;this._tokenizer?.updateTokensUntilLine(t,e),this.setTokens(t.finalize()),this._defaultBackgroundTokenizer?.checkFinished()}hasAccurateTokensForLine(e){return!this._tokenizer||this._tokenizer.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return!this._tokenizer||this._tokenizer.isCheapToTokenize(e)}getLineTokens(e){const t=this._textModel.getLineContent(e),i=this._tokens.getTokens(this._textModel.getLanguageId(),e-1,t);if(this._debugBackgroundTokens&&this._debugBackgroundStates&&this._tokenizer&&this._debugBackgroundStates.getFirstInvalidEndStateLineNumberOrMax()>e&&this._tokenizer.store.getFirstInvalidEndStateLineNumberOrMax()>e){const s=this._debugBackgroundTokens.getTokens(this._textModel.getLanguageId(),e-1,t);!i.equals(s)&&this._debugBackgroundTokenizer.value?.reportMismatchingTokens&&this._debugBackgroundTokenizer.value.reportMismatchingTokens(e)}return i}getTokenTypeIfInsertingCharacter(e,t,i){if(!this._tokenizer)return 0;const s=this._textModel.validatePosition(new u.y(e,t));return this.forceTokenization(s.lineNumber),this._tokenizer.getTokenTypeIfInsertingCharacter(s,i)}tokenizeLineWithEdit(e,t,i){if(!this._tokenizer)return null;const s=this._textModel.validatePosition(e);return this.forceTokenization(s.lineNumber),this._tokenizer.tokenizeLineWithEdit(s,t,i)}get hasTokens(){return this._tokens.hasTokens}}var Nt,It=i(64727),Ot=i(63591),Dt=i(47579),Mt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Pt=function(e,t){return function(i,s){t(i,s,e)}};function Ft(e,t){let i;return i="string"===typeof e?function(e){const t=new Ke;return t.acceptChunk(e),t.finish()}(e):v.nk(e)?function(e){const t=new Ke;let i;for(;"string"===typeof(i=e.read());)t.acceptChunk(i);return t.finish()}(e):e,i.create(t)}let Ut=0;class Ht{constructor(e){this._source=e,this._eos=!1}read(){if(this._eos)return null;const e=[];let t=0,i=0;for(;;){const s=this._source.read();if(null===s)return this._eos=!0,0===t?null:e.join("");if(s.length>0&&(e[t++]=s,i+=s.length),i>=65536)return e.join("")}}}const Bt=()=>{throw new Error("Invalid change accessor")};let Wt=class extends a.jG{static{Nt=this}static{this._MODEL_SYNC_LIMIT=52428800}static{this.LARGE_FILE_SIZE_THRESHOLD=20971520}static{this.LARGE_FILE_LINE_COUNT_THRESHOLD=3e5}static{this.LARGE_FILE_HEAP_OPERATION_THRESHOLD=268435456}static{this.DEFAULT_CREATION_OPTIONS={isForSimpleWidget:!1,tabSize:m.R.tabSize,indentSize:m.R.indentSize,insertSpaces:m.R.insertSpaces,detectIndentation:!1,defaultEOL:1,trimAutoWhitespace:m.R.trimAutoWhitespace,largeFileOptimizations:m.R.largeFileOptimizations,bracketPairColorizationOptions:m.R.bracketPairColorizationOptions}}static resolveOptions(e,t){if(t.detectIndentation){const i=$(e,t.tabSize,t.insertSpaces);return new v.X2({tabSize:i.tabSize,indentSize:"tabSize",insertSpaces:i.insertSpaces,trimAutoWhitespace:t.trimAutoWhitespace,defaultEOL:t.defaultEOL,bracketPairColorizationOptions:t.bracketPairColorizationOptions})}return new v.X2(t)}get onDidChangeLanguage(){return this._tokenizationTextModelPart.onDidChangeLanguage}get onDidChangeLanguageConfiguration(){return this._tokenizationTextModelPart.onDidChangeLanguageConfiguration}get onDidChangeTokens(){return this._tokenizationTextModelPart.onDidChangeTokens}onDidChangeContent(e){return this._eventEmitter.slowEvent((t=>e(t.contentChangedEvent)))}onDidChangeContentOrInjectedText(e){return(0,a.qE)(this._eventEmitter.fastEvent((t=>e(t))),this._onDidChangeInjectedText.event((t=>e(t))))}_isDisposing(){return this.__isDisposing}get tokenization(){return this._tokenizationTextModelPart}get bracketPairs(){return this._bracketPairs}get guides(){return this._guidesTextModelPart}constructor(e,t,i,s=null,n,r,h,d){super(),this._undoRedoService=n,this._languageService=r,this._languageConfigurationService=h,this.instantiationService=d,this._onWillDispose=this._register(new o.vl),this.onWillDispose=this._onWillDispose.event,this._onDidChangeDecorations=this._register(new ei((e=>this.handleBeforeFireDecorationsChangedEvent(e)))),this.onDidChangeDecorations=this._onDidChangeDecorations.event,this._onDidChangeOptions=this._register(new o.vl),this.onDidChangeOptions=this._onDidChangeOptions.event,this._onDidChangeAttached=this._register(new o.vl),this.onDidChangeAttached=this._onDidChangeAttached.event,this._onDidChangeInjectedText=this._register(new o.vl),this._eventEmitter=this._register(new ti),this._languageSelectionListener=this._register(new a.HE),this._deltaDecorationCallCnt=0,this._attachedViews=new gt,Ut++,this.id="$model"+Ut,this.isForSimpleWidget=i.isForSimpleWidget,this._associatedResource="undefined"===typeof s||null===s?l.r.parse("inmemory://model/"+Ut):s,this._attachedEditorCount=0;const{textBuffer:u,disposable:p}=Ft(e,i.defaultEOL);this._buffer=u,this._bufferDisposable=p,this._options=Nt.resolveOptions(this._buffer,i);const m="string"===typeof t?t:t.languageId;"string"!==typeof t&&(this._languageSelectionListener.value=t.onDidChange((()=>this._setLanguage(t.languageId)))),this._bracketPairs=this._register(new F(this,this._languageConfigurationService)),this._guidesTextModelPart=this._register(new K.P(this,this._languageConfigurationService)),this._decorationProvider=this._register(new z(this)),this._tokenizationTextModelPart=this.instantiationService.createInstance(kt,this,this._bracketPairs,m,this._attachedViews);const f=this._buffer.getLineCount(),_=this._buffer.getValueLengthInRange(new g.Q(1,1,f,this._buffer.getLineLength(f)+1),0);i.largeFileOptimizations?(this._isTooLargeForTokenization=_>Nt.LARGE_FILE_SIZE_THRESHOLD||f>Nt.LARGE_FILE_LINE_COUNT_THRESHOLD,this._isTooLargeForHeapOperation=_>Nt.LARGE_FILE_HEAP_OPERATION_THRESHOLD):(this._isTooLargeForTokenization=!1,this._isTooLargeForHeapOperation=!1),this._isTooLargeForSyncing=_>Nt._MODEL_SYNC_LIMIT,this._versionId=1,this._alternativeVersionId=1,this._initialUndoRedoSnapshot=null,this._isDisposed=!1,this.__isDisposing=!1,this._instanceId=c.tk(Ut),this._lastDecorationId=0,this._decorations=Object.create(null),this._decorationsTree=new Gt,this._commandManager=new j.z8(this,this._undoRedoService),this._isUndoing=!1,this._isRedoing=!1,this._trimAutoWhitespaceLines=null,this._register(this._decorationProvider.onDidChange((()=>{this._onDidChangeDecorations.beginDeferredEmit(),this._onDidChangeDecorations.fire(),this._onDidChangeDecorations.endDeferredEmit()}))),this._languageService.requestRichLanguageFeatures(m),this._register(this._languageConfigurationService.onDidChange((e=>{this._bracketPairs.handleLanguageConfigurationServiceChange(e),this._tokenizationTextModelPart.handleLanguageConfigurationServiceChange(e)})))}dispose(){this.__isDisposing=!0,this._onWillDispose.fire(),this._tokenizationTextModelPart.dispose(),this._isDisposed=!0,super.dispose(),this._bufferDisposable.dispose(),this.__isDisposing=!1;const e=new Ge([],"","\n",!1,!1,!0,!0);e.dispose(),this._buffer=e,this._bufferDisposable=a.jG.None}_assertNotDisposed(){if(this._isDisposed)throw new r.D7("Model is disposed!")}_emitContentChangedEvent(e,t){this.__isDisposing||(this._tokenizationTextModelPart.handleDidChangeContent(t),this._bracketPairs.handleDidChangeContent(t),this._eventEmitter.fire(new It.Ic(e,t)))}setValue(e){if(this._assertNotDisposed(),null===e||void 0===e)throw(0,r.Qg)();const{textBuffer:t,disposable:i}=Ft(e,this._options.defaultEOL);this._setValueFromTextBuffer(t,i)}_createContentChanged2(e,t,i,s,n,r,o,a){return{changes:[{range:e,rangeOffset:t,rangeLength:i,text:s}],eol:this._buffer.getEOL(),isEolChange:a,versionId:this.getVersionId(),isUndoing:n,isRedoing:r,isFlush:o}}_setValueFromTextBuffer(e,t){this._assertNotDisposed();const i=this.getFullModelRange(),s=this.getValueLengthInRange(i),n=this.getLineCount(),r=this.getLineMaxColumn(n);this._buffer=e,this._bufferDisposable.dispose(),this._bufferDisposable=t,this._increaseVersionId(),this._decorations=Object.create(null),this._decorationsTree=new Gt,this._commandManager.clear(),this._trimAutoWhitespaceLines=null,this._emitContentChangedEvent(new It.HP([new It.Wn],this._versionId,!1,!1),this._createContentChanged2(new g.Q(1,1,n,r),0,s,this.getValue(),!1,!1,!0,!1))}setEOL(e){this._assertNotDisposed();const t=1===e?"\r\n":"\n";if(this._buffer.getEOL()===t)return;const i=this.getFullModelRange(),s=this.getValueLengthInRange(i),n=this.getLineCount(),r=this.getLineMaxColumn(n);this._onBeforeEOLChange(),this._buffer.setEOL(t),this._increaseVersionId(),this._onAfterEOLChange(),this._emitContentChangedEvent(new It.HP([new It.mS],this._versionId,!1,!1),this._createContentChanged2(new g.Q(1,1,n,r),0,s,this.getValue(),!1,!1,!1,!0))}_onBeforeEOLChange(){this._decorationsTree.ensureAllNodesHaveRanges(this)}_onAfterEOLChange(){const e=this.getVersionId(),t=this._decorationsTree.collectNodesPostOrder();for(let i=0,s=t.length;i0}getAttachedEditorCount(){return this._attachedEditorCount}isTooLargeForSyncing(){return this._isTooLargeForSyncing}isTooLargeForTokenization(){return this._isTooLargeForTokenization}isTooLargeForHeapOperation(){return this._isTooLargeForHeapOperation}isDisposed(){return this._isDisposed}isDominatedByLongLines(){if(this._assertNotDisposed(),this.isTooLargeForTokenization())return!1;let e=0,t=0;const i=this._buffer.getLineCount();for(let s=1;s<=i;s++){const i=this._buffer.getLineLength(s);i>=1e4?t+=i:e+=i}return t>e}get uri(){return this._associatedResource}getOptions(){return this._assertNotDisposed(),this._options}getFormattingOptions(){return{tabSize:this._options.indentSize,insertSpaces:this._options.insertSpaces}}updateOptions(e){this._assertNotDisposed();const t="undefined"!==typeof e.tabSize?e.tabSize:this._options.tabSize,i="undefined"!==typeof e.indentSize?e.indentSize:this._options.originalIndentSize,s="undefined"!==typeof e.insertSpaces?e.insertSpaces:this._options.insertSpaces,n="undefined"!==typeof e.trimAutoWhitespace?e.trimAutoWhitespace:this._options.trimAutoWhitespace,r="undefined"!==typeof e.bracketColorizationOptions?e.bracketColorizationOptions:this._options.bracketPairColorizationOptions,o=new v.X2({tabSize:t,indentSize:i,insertSpaces:s,defaultEOL:this._options.defaultEOL,trimAutoWhitespace:n,bracketPairColorizationOptions:r});if(this._options.equals(o))return;const a=this._options.createChangeEvent(o);this._options=o,this._bracketPairs.handleDidChangeOptions(a),this._decorationProvider.handleDidChangeOptions(a),this._onDidChangeOptions.fire(a)}detectIndentation(e,t){this._assertNotDisposed();const i=$(this._buffer,t,e);this.updateOptions({insertSpaces:i.insertSpaces,tabSize:i.tabSize,indentSize:i.tabSize})}normalizeIndentation(e){return this._assertNotDisposed(),(0,d.P)(e,this._options.indentSize,this._options.insertSpaces)}getVersionId(){return this._assertNotDisposed(),this._versionId}mightContainRTL(){return this._buffer.mightContainRTL()}mightContainUnusualLineTerminators(){return this._buffer.mightContainUnusualLineTerminators()}removeUnusualLineTerminators(e=null){const t=this.findMatches(c._J.source,!1,!0,!1,null,!1,1073741824);this._buffer.resetMightContainUnusualLineTerminators(),this.pushEditOperations(e,t.map((e=>({range:e.range,text:null}))),(()=>null))}mightContainNonBasicASCII(){return this._buffer.mightContainNonBasicASCII()}getAlternativeVersionId(){return this._assertNotDisposed(),this._alternativeVersionId}getInitialUndoRedoSnapshot(){return this._assertNotDisposed(),this._initialUndoRedoSnapshot}getOffsetAt(e){this._assertNotDisposed();const t=this._validatePosition(e.lineNumber,e.column,0);return this._buffer.getOffsetAt(t.lineNumber,t.column)}getPositionAt(e){this._assertNotDisposed();const t=Math.min(this._buffer.getLength(),Math.max(0,e));return this._buffer.getPositionAt(t)}_increaseVersionId(){this._versionId=this._versionId+1,this._alternativeVersionId=this._versionId}_overwriteVersionId(e){this._versionId=e}_overwriteAlternativeVersionId(e){this._alternativeVersionId=e}_overwriteInitialUndoRedoSnapshot(e){this._initialUndoRedoSnapshot=e}getValue(e,t=!1){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new r.D7("Operation would exceed heap memory limits");const i=this.getFullModelRange(),s=this.getValueInRange(i,e);return t?this._buffer.getBOM()+s:s}createSnapshot(e=!1){return new Ht(this._buffer.createSnapshot(e))}getValueLength(e,t=!1){this._assertNotDisposed();const i=this.getFullModelRange(),s=this.getValueLengthInRange(i,e);return t?this._buffer.getBOM().length+s:s}getValueInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueInRange(this.validateRange(e),t)}getValueLengthInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueLengthInRange(this.validateRange(e),t)}getCharacterCountInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getCharacterCountInRange(this.validateRange(e),t)}getLineCount(){return this._assertNotDisposed(),this._buffer.getLineCount()}getLineContent(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineContent(e)}getLineLength(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)}getLinesContent(){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new r.D7("Operation would exceed heap memory limits");return this._buffer.getLinesContent()}getEOL(){return this._assertNotDisposed(),this._buffer.getEOL()}getEndOfLineSequence(){return this._assertNotDisposed(),"\n"===this._buffer.getEOL()?0:1}getLineMinColumn(e){return this._assertNotDisposed(),1}getLineMaxColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)+1}getLineFirstNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineFirstNonWhitespaceColumn(e)}getLineLastNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineLastNonWhitespaceColumn(e)}_validateRangeRelaxedNoAllocations(e){const t=this._buffer.getLineCount(),i=e.startLineNumber,s=e.startColumn;let n=Math.floor("number"!==typeof i||isNaN(i)?1:i),r=Math.floor("number"!==typeof s||isNaN(s)?1:s);if(n<1)n=1,r=1;else if(n>t)n=t,r=this.getLineMaxColumn(n);else if(r<=1)r=1;else{const e=this.getLineMaxColumn(n);r>=e&&(r=e)}const o=e.endLineNumber,a=e.endColumn;let c=Math.floor("number"!==typeof o||isNaN(o)?1:o),l=Math.floor("number"!==typeof a||isNaN(a)?1:a);if(c<1)c=1,l=1;else if(c>t)c=t,l=this.getLineMaxColumn(c);else if(l<=1)l=1;else{const e=this.getLineMaxColumn(c);l>=e&&(l=e)}return i===n&&s===r&&o===c&&a===l&&e instanceof g.Q&&!(e instanceof p.L)?e:new g.Q(n,r,c,l)}_isValidPosition(e,t,i){if("number"!==typeof e||"number"!==typeof t)return!1;if(isNaN(e)||isNaN(t))return!1;if(e<1||t<1)return!1;if((0|e)!==e||(0|t)!==t)return!1;if(e>this._buffer.getLineCount())return!1;if(1===t)return!0;if(t>this.getLineMaxColumn(e))return!1;if(1===i){const i=this._buffer.getLineCharCode(e,t-2);if(c.pc(i))return!1}return!0}_validatePosition(e,t,i){const s=Math.floor("number"!==typeof e||isNaN(e)?1:e),n=Math.floor("number"!==typeof t||isNaN(t)?1:t),r=this._buffer.getLineCount();if(s<1)return new u.y(1,1);if(s>r)return new u.y(r,this.getLineMaxColumn(r));if(n<=1)return new u.y(s,1);const o=this.getLineMaxColumn(s);if(n>=o)return new u.y(s,o);if(1===i){const e=this._buffer.getLineCharCode(s,n-2);if(c.pc(e))return new u.y(s,n-1)}return new u.y(s,n)}validatePosition(e){return this._assertNotDisposed(),e instanceof u.y&&this._isValidPosition(e.lineNumber,e.column,1)?e:this._validatePosition(e.lineNumber,e.column,1)}_isValidRange(e,t){const i=e.startLineNumber,s=e.startColumn,n=e.endLineNumber,r=e.endColumn;if(!this._isValidPosition(i,s,0))return!1;if(!this._isValidPosition(n,r,0))return!1;if(1===t){const e=s>1?this._buffer.getLineCharCode(i,s-2):0,t=r>1&&r<=this._buffer.getLineLength(n)?this._buffer.getLineCharCode(n,r-2):0,o=c.pc(e),a=c.pc(t);return!o&&!a}return!0}validateRange(e){if(this._assertNotDisposed(),e instanceof g.Q&&!(e instanceof p.L)&&this._isValidRange(e,1))return e;const t=this._validatePosition(e.startLineNumber,e.startColumn,0),i=this._validatePosition(e.endLineNumber,e.endColumn,0),s=t.lineNumber,n=t.column,r=i.lineNumber,o=i.column;{const e=n>1?this._buffer.getLineCharCode(s,n-2):0,t=o>1&&o<=this._buffer.getLineLength(r)?this._buffer.getLineCharCode(r,o-2):0,i=c.pc(e),a=c.pc(t);return i||a?s===r&&n===o?new g.Q(s,n-1,r,o-1):i&&a?new g.Q(s,n-1,r,o+1):i?new g.Q(s,n-1,r,o):new g.Q(s,n,r,o+1):new g.Q(s,n,r,o)}}modifyPosition(e,t){this._assertNotDisposed();const i=this.getOffsetAt(e)+t;return this.getPositionAt(Math.min(this._buffer.getLength(),Math.max(0,i)))}getFullModelRange(){this._assertNotDisposed();const e=this.getLineCount();return new g.Q(1,1,e,this.getLineMaxColumn(e))}findMatchesLineByLine(e,t,i,s){return this._buffer.findMatchesLineByLine(e,t,i,s)}findMatches(e,t,i,s,n,r,o=999){this._assertNotDisposed();let a=null;null!==t&&(Array.isArray(t)||(t=[t]),t.every((e=>g.Q.isIRange(e)))&&(a=t.map((e=>this.validateRange(e))))),null===a&&(a=[this.getFullModelRange()]),a=a.sort(((e,t)=>e.startLineNumber-t.startLineNumber||e.startColumn-t.startColumn));const c=[];let l;if(c.push(a.reduce(((e,t)=>g.Q.areIntersecting(e,t)?e.plusRange(t):(c.push(e),t)))),!i&&e.indexOf("\n")<0){const t=new Oe.lt(e,i,s,n).parseSearchRequest();if(!t)return[];l=e=>this.findMatchesLineByLine(e,t,r,o)}else l=t=>Oe.hB.findMatches(this,new Oe.lt(e,i,s,n),t,r,o);return c.map(l).reduce(((e,t)=>e.concat(t)),[])}findNextMatch(e,t,i,s,n,r){this._assertNotDisposed();const o=this.validatePosition(t);if(!i&&e.indexOf("\n")<0){const t=new Oe.lt(e,i,s,n).parseSearchRequest();if(!t)return null;const a=this.getLineCount();let c=new g.Q(o.lineNumber,o.column,a,this.getLineMaxColumn(a)),l=this.findMatchesLineByLine(c,t,r,1);return Oe.hB.findNextMatch(this,new Oe.lt(e,i,s,n),o,r),l.length>0?l[0]:(c=new g.Q(1,1,o.lineNumber,this.getLineMaxColumn(o.lineNumber)),l=this.findMatchesLineByLine(c,t,r,1),l.length>0?l[0]:null)}return Oe.hB.findNextMatch(this,new Oe.lt(e,i,s,n),o,r)}findPreviousMatch(e,t,i,s,n,r){this._assertNotDisposed();const o=this.validatePosition(t);return Oe.hB.findPreviousMatch(this,new Oe.lt(e,i,s,n),o,r)}pushStackElement(){this._commandManager.pushStackElement()}popStackElement(){this._commandManager.popStackElement()}pushEOL(e){if(("\n"===this.getEOL()?0:1)!==e)try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEOL(e)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_validateEditOperation(e){return e instanceof v.Wo?e:new v.Wo(e.identifier||null,this.validateRange(e.range),e.text,e.forceMoveMarkers||!1,e.isAutoWhitespaceEdit||!1,e._isTracked||!1)}_validateEditOperations(e){const t=[];for(let i=0,s=e.length;i({range:this.validateRange(e.range),text:e.text})));let s=!0;if(e)for(let t=0,n=e.length;tn.endLineNumber,o=n.startLineNumber>t.endLineNumber;if(!s&&!o){r=!0;break}}if(!r){s=!1;break}}if(s)for(let e=0,n=this._trimAutoWhitespaceLines.length;et.endLineNumber)&&(!(s===t.startLineNumber&&t.startColumn===n&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(0))&&!(s===t.startLineNumber&&1===t.startColumn&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(o.length-1)))){r=!1;break}}if(r){const e=new g.Q(s,1,s,n);t.push(new v.Wo(null,e,null,!1,!1,!1))}}this._trimAutoWhitespaceLines=null}return null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEditOperation(e,t,i,s)}_applyUndo(e,t,i,s){const n=e.map((e=>{const t=this.getPositionAt(e.newPosition),i=this.getPositionAt(e.newEnd);return{range:new g.Q(t.lineNumber,t.column,i.lineNumber,i.column),text:e.oldText}}));this._applyUndoRedoEdits(n,t,!0,!1,i,s)}_applyRedo(e,t,i,s){const n=e.map((e=>{const t=this.getPositionAt(e.oldPosition),i=this.getPositionAt(e.oldEnd);return{range:new g.Q(t.lineNumber,t.column,i.lineNumber,i.column),text:e.newText}}));this._applyUndoRedoEdits(n,t,!1,!0,i,s)}_applyUndoRedoEdits(e,t,i,s,n,r){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),this._isUndoing=i,this._isRedoing=s,this.applyEdits(e,!1),this.setEOL(t),this._overwriteAlternativeVersionId(n)}finally{this._isUndoing=!1,this._isRedoing=!1,this._eventEmitter.endDeferredEmit(r),this._onDidChangeDecorations.endDeferredEmit()}}applyEdits(e,t=!1){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit();const i=this._validateEditOperations(e);return this._doApplyEdits(i,t)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_doApplyEdits(e,t){const i=this._buffer.getLineCount(),n=this._buffer.applyEdits(e,this._options.trimAutoWhitespace,t),r=this._buffer.getLineCount(),o=n.changes;if(this._trimAutoWhitespaceLines=n.trimAutoWhitespaceLineNumbers,0!==o.length){for(let i=0,s=o.length;i=0;t--){const i=c+t,s=f+t;b.takeFromEndWhile((e=>e.lineNumber>s));const n=b.takeFromEndWhile((e=>e.lineNumber===s));e.push(new It.U0(i,this.getLineContent(s),n))}if(pe.lineNumbere.lineNumber===t))}e.push(new It.bg(n+1,c+g,h,l))}t+=m}this._emitContentChangedEvent(new It.HP(e,this.getVersionId(),this._isUndoing,this._isRedoing),{changes:o,eol:this._buffer.getEOL(),isEolChange:!1,versionId:this.getVersionId(),isUndoing:this._isUndoing,isRedoing:this._isRedoing,isFlush:!1})}return null===n.reverseEdits?void 0:n.reverseEdits}undo(){return this._undoRedoService.undo(this.uri)}canUndo(){return this._undoRedoService.canUndo(this.uri)}redo(){return this._undoRedoService.redo(this.uri)}canRedo(){return this._undoRedoService.canRedo(this.uri)}handleBeforeFireDecorationsChangedEvent(e){if(null===e||0===e.size)return;const t=Array.from(e).map((e=>new It.U0(e,this.getLineContent(e),this._getInjectedTextInLine(e))));this._onDidChangeInjectedText.fire(new It.vn(t))}changeDecorations(e,t=0){this._assertNotDisposed();try{return this._onDidChangeDecorations.beginDeferredEmit(),this._changeDecorations(t,e)}finally{this._onDidChangeDecorations.endDeferredEmit()}}_changeDecorations(e,t){const i={addDecoration:(t,i)=>this._deltaDecorationsImpl(e,[],[{range:t,options:i}])[0],changeDecoration:(e,t)=>{this._changeDecorationImpl(e,t)},changeDecorationOptions:(e,t)=>{this._changeDecorationOptionsImpl(e,Jt(t))},removeDecoration:t=>{this._deltaDecorationsImpl(e,[t],[])},deltaDecorations:(t,i)=>0===t.length&&0===i.length?[]:this._deltaDecorationsImpl(e,t,i)};let s=null;try{s=t(i)}catch(n){(0,r.dz)(n)}return i.addDecoration=Bt,i.changeDecoration=Bt,i.changeDecorationOptions=Bt,i.removeDecoration=Bt,i.deltaDecorations=Bt,s}deltaDecorations(e,t,i=0){if(this._assertNotDisposed(),e||(e=[]),0===e.length&&0===t.length)return[];try{return this._deltaDecorationCallCnt++,this._deltaDecorationCallCnt>1&&(console.warn("Invoking deltaDecorations recursively could lead to leaking decorations."),(0,r.dz)(new Error("Invoking deltaDecorations recursively could lead to leaking decorations."))),this._onDidChangeDecorations.beginDeferredEmit(),this._deltaDecorationsImpl(i,e,t)}finally{this._onDidChangeDecorations.endDeferredEmit(),this._deltaDecorationCallCnt--}}_getTrackedRange(e){return this.getDecorationRange(e)}_setTrackedRange(e,t,i){const s=e?this._decorations[e]:null;if(!s)return t?this._deltaDecorationsImpl(0,[],[{range:t,options:Zt[i]}],!0)[0]:null;if(!t)return this._decorationsTree.delete(s),delete this._decorations[s.id],null;const n=this._validateRangeRelaxedNoAllocations(t),r=this._buffer.getOffsetAt(n.startLineNumber,n.startColumn),o=this._buffer.getOffsetAt(n.endLineNumber,n.endColumn);return this._decorationsTree.delete(s),s.reset(this.getVersionId(),r,o,n),s.setOptions(Zt[i]),this._decorationsTree.insert(s),s.id}removeAllDecorationsWithOwnerId(e){if(this._isDisposed)return;const t=this._decorationsTree.collectNodesFromOwner(e);for(let i=0,s=t.length;ithis.getLineCount()?[]:this.getLinesDecorations(e,e,t,i)}getLinesDecorations(e,t,i=0,n=!1,r=!1){const o=this.getLineCount(),a=Math.min(o,Math.max(1,e)),c=Math.min(o,Math.max(1,t)),l=this.getLineMaxColumn(c),h=new g.Q(a,1,c,l),d=this._getDecorationsInRange(h,i,n,r);return(0,s.E4)(d,this._decorationProvider.getDecorationsInRange(h,i,n)),d}getDecorationsInRange(e,t=0,i=!1,n=!1,r=!1){const o=this.validateRange(e),a=this._getDecorationsInRange(o,t,i,r);return(0,s.E4)(a,this._decorationProvider.getDecorationsInRange(o,t,i,n)),a}getOverviewRulerDecorations(e=0,t=!1){return this._decorationsTree.getAll(this,e,t,!0,!1)}getInjectedTextDecorations(e=0){return this._decorationsTree.getAllInjectedText(this,e)}_getInjectedTextInLine(e){const t=this._buffer.getOffsetAt(e,1),i=t+this._buffer.getLineLength(e),s=this._decorationsTree.getInjectedTextInInterval(this,t,i,0);return It.uK.fromDecorations(s).filter((t=>t.lineNumber===e))}getAllDecorations(e=0,t=!1){let i=this._decorationsTree.getAll(this,e,t,!1,!1);return i=i.concat(this._decorationProvider.getAllDecorations(e,t)),i}getAllMarginDecorations(e=0){return this._decorationsTree.getAll(this,e,!1,!1,!0)}_getDecorationsInRange(e,t,i,s){const n=this._buffer.getOffsetAt(e.startLineNumber,e.startColumn),r=this._buffer.getOffsetAt(e.endLineNumber,e.endColumn);return this._decorationsTree.getAllInInterval(this,n,r,t,i,s)}getRangeAt(e,t){return this._buffer.getRangeAt(e,t-e)}_changeDecorationImpl(e,t){const i=this._decorations[e];if(!i)return;if(i.options.after){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.endLineNumber)}if(i.options.before){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.startLineNumber)}const s=this._validateRangeRelaxedNoAllocations(t),n=this._buffer.getOffsetAt(s.startLineNumber,s.startColumn),r=this._buffer.getOffsetAt(s.endLineNumber,s.endColumn);this._decorationsTree.delete(i),i.reset(this.getVersionId(),n,r,s),this._decorationsTree.insert(i),this._onDidChangeDecorations.checkAffectedAndFire(i.options),i.options.after&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(s.endLineNumber),i.options.before&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(s.startLineNumber)}_changeDecorationOptionsImpl(e,t){const i=this._decorations[e];if(!i)return;const s=!(!i.options.overviewRuler||!i.options.overviewRuler.color),n=!(!t.overviewRuler||!t.overviewRuler.color);if(this._onDidChangeDecorations.checkAffectedAndFire(i.options),this._onDidChangeDecorations.checkAffectedAndFire(t),i.options.after||t.after){const e=this._decorationsTree.getNodeRange(this,i);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.endLineNumber)}if(i.options.before||t.before){const e=this._decorationsTree.getNodeRange(this,i);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.startLineNumber)}const r=s!==n,o=function(e){return!!e.after||!!e.before}(t)!==zt(i);r||o?(this._decorationsTree.delete(i),i.setOptions(t),this._decorationsTree.insert(i)):i.setOptions(t)}_deltaDecorationsImpl(e,t,i,s=!1){const n=this.getVersionId(),r=t.length;let o=0;const a=i.length;let c=0;this._onDidChangeDecorations.beginDeferredEmit();try{const l=new Array(a);for(;othis._setLanguage(e.languageId,t))),this._setLanguage(e.languageId,t))}_setLanguage(e,t){this.tokenization.setLanguageId(e,t),this._languageService.requestRichLanguageFeatures(e)}getLanguageIdAtPosition(e,t){return this.tokenization.getLanguageIdAtPosition(e,t)}getWordAtPosition(e){return this._tokenizationTextModelPart.getWordAtPosition(e)}getWordUntilPosition(e){return this._tokenizationTextModelPart.getWordUntilPosition(e)}normalizePosition(e,t){return e}getLineIndentColumn(e){return function(e){let t=0;for(const i of e){if(" "!==i&&"\t"!==i)break;t++}return t}(this.getLineContent(e))+1}};function Vt(e){return!(!e.options.overviewRuler||!e.options.overviewRuler.color)}function zt(e){return!!e.options.after||!!e.options.before}Wt=Nt=Mt([Pt(4,Dt.$D),Pt(5,f.L),Pt(6,_.JZ),Pt(7,Ot._Y)],Wt);class Gt{constructor(){this._decorationsTree0=new ce,this._decorationsTree1=new ce,this._injectedTextDecorationsTree=new ce}ensureAllNodesHaveRanges(e){this.getAll(e,0,!1,!1,!1)}_ensureNodesHaveRanges(e,t){for(const i of t)null===i.range&&(i.range=e.getRangeAt(i.cachedAbsoluteStart,i.cachedAbsoluteEnd));return t}getAllInInterval(e,t,i,s,n,r){const o=e.getVersionId(),a=this._intervalSearch(t,i,s,n,o,r);return this._ensureNodesHaveRanges(e,a)}_intervalSearch(e,t,i,s,n,r){const o=this._decorationsTree0.intervalSearch(e,t,i,s,n,r),a=this._decorationsTree1.intervalSearch(e,t,i,s,n,r),c=this._injectedTextDecorationsTree.intervalSearch(e,t,i,s,n,r);return o.concat(a).concat(c)}getInjectedTextInInterval(e,t,i,s){const n=e.getVersionId(),r=this._injectedTextDecorationsTree.intervalSearch(t,i,s,!1,n,!1);return this._ensureNodesHaveRanges(e,r).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAllInjectedText(e,t){const i=e.getVersionId(),s=this._injectedTextDecorationsTree.search(t,!1,i,!1);return this._ensureNodesHaveRanges(e,s).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAll(e,t,i,s,n){const r=e.getVersionId(),o=this._search(t,i,s,r,n);return this._ensureNodesHaveRanges(e,o)}_search(e,t,i,s,n){if(i)return this._decorationsTree1.search(e,t,s,n);{const i=this._decorationsTree0.search(e,t,s,n),r=this._decorationsTree1.search(e,t,s,n),o=this._injectedTextDecorationsTree.search(e,t,s,n);return i.concat(r).concat(o)}}collectNodesFromOwner(e){const t=this._decorationsTree0.collectNodesFromOwner(e),i=this._decorationsTree1.collectNodesFromOwner(e),s=this._injectedTextDecorationsTree.collectNodesFromOwner(e);return t.concat(i).concat(s)}collectNodesPostOrder(){const e=this._decorationsTree0.collectNodesPostOrder(),t=this._decorationsTree1.collectNodesPostOrder(),i=this._injectedTextDecorationsTree.collectNodesPostOrder();return e.concat(t).concat(i)}insert(e){zt(e)?this._injectedTextDecorationsTree.insert(e):Vt(e)?this._decorationsTree1.insert(e):this._decorationsTree0.insert(e)}delete(e){zt(e)?this._injectedTextDecorationsTree.delete(e):Vt(e)?this._decorationsTree1.delete(e):this._decorationsTree0.delete(e)}getNodeRange(e,t){const i=e.getVersionId();return t.cachedVersionId!==i&&this._resolveNode(t,i),null===t.range&&(t.range=e.getRangeAt(t.cachedAbsoluteStart,t.cachedAbsoluteEnd)),t.range}_resolveNode(e,t){zt(e)?this._injectedTextDecorationsTree.resolveNode(e,t):Vt(e)?this._decorationsTree1.resolveNode(e,t):this._decorationsTree0.resolveNode(e,t)}acceptReplace(e,t,i,s){this._decorationsTree0.acceptReplace(e,t,i,s),this._decorationsTree1.acceptReplace(e,t,i,s),this._injectedTextDecorationsTree.acceptReplace(e,t,i,s)}}function jt(e){return e.replace(/[^a-z0-9\-_]/gi," ")}class Kt{constructor(e){this.color=e.color||"",this.darkColor=e.darkColor||""}}class Yt extends Kt{constructor(e){super(e),this._resolvedColor=null,this.position="number"===typeof e.position?e.position:v.A5.Center}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=null}_resolveColor(e,t){if("string"===typeof e)return e;const i=e?t.getColor(e.id):null;return i?i.toString():""}}class qt{constructor(e){this.position=e?.position??v.ZS.Center,this.persistLane=e?.persistLane}}class $t extends Kt{constructor(e){super(e),this.position=e.position,this.sectionHeaderStyle=e.sectionHeaderStyle??null,this.sectionHeaderText=e.sectionHeaderText??null}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=void 0}_resolveColor(e,t){return"string"===typeof e?n.Q1.fromHex(e):t.getColor(e.id)}}class Qt{static from(e){return e instanceof Qt?e:new Qt(e)}constructor(e){this.content=e.content||"",this.inlineClassName=e.inlineClassName||null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.attachedData=e.attachedData||null,this.cursorStops=e.cursorStops||null}}class Xt{static register(e){return new Xt(e)}static createDynamic(e){return new Xt(e)}constructor(e){this.description=e.description,this.blockClassName=e.blockClassName?jt(e.blockClassName):null,this.blockDoesNotCollapse=e.blockDoesNotCollapse??null,this.blockIsAfterEnd=e.blockIsAfterEnd??null,this.blockPadding=e.blockPadding??null,this.stickiness=e.stickiness||0,this.zIndex=e.zIndex||0,this.className=e.className?jt(e.className):null,this.shouldFillLineOnLineBreak=e.shouldFillLineOnLineBreak??null,this.hoverMessage=e.hoverMessage||null,this.glyphMarginHoverMessage=e.glyphMarginHoverMessage||null,this.lineNumberHoverMessage=e.lineNumberHoverMessage||null,this.isWholeLine=e.isWholeLine||!1,this.showIfCollapsed=e.showIfCollapsed||!1,this.collapseOnReplaceEdit=e.collapseOnReplaceEdit||!1,this.overviewRuler=e.overviewRuler?new Yt(e.overviewRuler):null,this.minimap=e.minimap?new $t(e.minimap):null,this.glyphMargin=e.glyphMarginClassName?new qt(e.glyphMargin):null,this.glyphMarginClassName=e.glyphMarginClassName?jt(e.glyphMarginClassName):null,this.linesDecorationsClassName=e.linesDecorationsClassName?jt(e.linesDecorationsClassName):null,this.lineNumberClassName=e.lineNumberClassName?jt(e.lineNumberClassName):null,this.linesDecorationsTooltip=e.linesDecorationsTooltip?c.jy(e.linesDecorationsTooltip):null,this.firstLineDecorationClassName=e.firstLineDecorationClassName?jt(e.firstLineDecorationClassName):null,this.marginClassName=e.marginClassName?jt(e.marginClassName):null,this.inlineClassName=e.inlineClassName?jt(e.inlineClassName):null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.beforeContentClassName=e.beforeContentClassName?jt(e.beforeContentClassName):null,this.afterContentClassName=e.afterContentClassName?jt(e.afterContentClassName):null,this.after=e.after?Qt.from(e.after):null,this.before=e.before?Qt.from(e.before):null,this.hideInCommentTokens=e.hideInCommentTokens??!1,this.hideInStringTokens=e.hideInStringTokens??!1}}Xt.EMPTY=Xt.register({description:"empty"});const Zt=[Xt.register({description:"tracked-range-always-grows-when-typing-at-edges",stickiness:0}),Xt.register({description:"tracked-range-never-grows-when-typing-at-edges",stickiness:1}),Xt.register({description:"tracked-range-grows-only-when-typing-before",stickiness:2}),Xt.register({description:"tracked-range-grows-only-when-typing-after",stickiness:3})];function Jt(e){return e instanceof Xt?e:Xt.createDynamic(e)}class ei extends a.jG{constructor(e){super(),this.handleBeforeFire=e,this._actual=this._register(new o.vl),this.event=this._actual.event,this._affectedInjectedTextLines=null,this._deferredCnt=0,this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._affectsLineNumber=!1}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(){this._deferredCnt--,0===this._deferredCnt&&(this._shouldFireDeferred&&this.doFire(),this._affectedInjectedTextLines?.clear(),this._affectedInjectedTextLines=null)}recordLineAffectedByInjectedText(e){this._affectedInjectedTextLines||(this._affectedInjectedTextLines=new Set),this._affectedInjectedTextLines.add(e)}checkAffectedAndFire(e){this._affectsMinimap||=!!e.minimap?.position,this._affectsOverviewRuler||=!!e.overviewRuler?.color,this._affectsGlyphMargin||=!!e.glyphMarginClassName,this._affectsLineNumber||=!!e.lineNumberClassName,this.tryFire()}fire(){this._affectsMinimap=!0,this._affectsOverviewRuler=!0,this._affectsGlyphMargin=!0,this.tryFire()}tryFire(){0===this._deferredCnt?this.doFire():this._shouldFireDeferred=!0}doFire(){this.handleBeforeFire(this._affectedInjectedTextLines);const e={affectsMinimap:this._affectsMinimap,affectsOverviewRuler:this._affectsOverviewRuler,affectsGlyphMargin:this._affectsGlyphMargin,affectsLineNumber:this._affectsLineNumber};this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._actual.fire(e)}}class ti extends a.jG{constructor(){super(),this._fastEmitter=this._register(new o.vl),this.fastEvent=this._fastEmitter.event,this._slowEmitter=this._register(new o.vl),this.slowEvent=this._slowEmitter.event,this._deferredCnt=0,this._deferredEvent=null}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(e=null){if(this._deferredCnt--,0===this._deferredCnt&&null!==this._deferredEvent){this._deferredEvent.rawContentChangedEvent.resultingSelection=e;const t=this._deferredEvent;this._deferredEvent=null,this._fastEmitter.fire(t),this._slowEmitter.fire(t)}}fire(e){this._deferredCnt>0?this._deferredEvent?this._deferredEvent=this._deferredEvent.merge(e):this._deferredEvent=e:(this._fastEmitter.fire(e),this._slowEmitter.fire(e))}}},87469:(e,t,i)=>{"use strict";i.d(t,{T:()=>o,f:()=>n});var s=i(25982);class n{static{this.defaultTokenMetadata=33587200}static createEmpty(e,t){const i=n.defaultTokenMetadata,s=new Uint32Array(2);return s[0]=e.length,s[1]=i,new n(s,e,t)}static createFromTextAndMetadata(e,t){let i=0,s="";const r=new Array;for(const{text:n,metadata:o}of e)r.push(i+n.length,o),i+=n.length,s+=n;return new n(new Uint32Array(r),s,t)}constructor(e,t,i){this._lineTokensBrand=void 0,this._tokens=e,this._tokensCount=this._tokens.length>>>1,this._text=t,this.languageIdCodec=i}equals(e){return e instanceof n&&this.slicedEquals(e,0,this._tokensCount)}slicedEquals(e,t,i){if(this._text!==e._text)return!1;if(this._tokensCount!==e._tokensCount)return!1;const s=t<<1,n=s+(i<<1);for(let r=s;r0?this._tokens[e-1<<1]:0}getMetadata(e){return this._tokens[1+(e<<1)]}getLanguageId(e){const t=this._tokens[1+(e<<1)],i=s.x.getLanguageId(t);return this.languageIdCodec.decodeLanguageId(i)}getStandardTokenType(e){const t=this._tokens[1+(e<<1)];return s.x.getTokenType(t)}getForeground(e){const t=this._tokens[1+(e<<1)];return s.x.getForeground(t)}getClassName(e){const t=this._tokens[1+(e<<1)];return s.x.getClassNameFromMetadata(t)}getInlineStyle(e,t){const i=this._tokens[1+(e<<1)];return s.x.getInlineStyleFromMetadata(i,t)}getPresentation(e){const t=this._tokens[1+(e<<1)];return s.x.getPresentationFromMetadata(t)}getEndOffset(e){return this._tokens[e<<1]}findTokenIndexAtOffset(e){return n.findIndexInTokensArray(this._tokens,e)}inflate(){return this}sliceAndInflate(e,t,i){return new r(this,e,t,i)}static convertToEndOffset(e,t){const i=(e.length>>>1)-1;for(let s=0;s>>1)-1;for(;it&&(s=n)}return i}withInserted(e){if(0===e.length)return this;let t=0,i=0,s="";const r=new Array;let o=0;for(;;){const n=to){s+=this._text.substring(o,a.offset);const e=this._tokens[1+(t<<1)];r.push(s.length,e),o=a.offset}s+=a.text,r.push(s.length,a.tokenMetadata),i++}}return new n(new Uint32Array(r),s,this.languageIdCodec)}getTokenText(e){const t=this.getStartOffset(e),i=this.getEndOffset(e);return this._text.substring(t,i)}forEach(e){const t=this.getCount();for(let i=0;i=i)break;this._tokensCount++}}getMetadata(e){return this._source.getMetadata(this._firstTokenIndex+e)}getLanguageId(e){return this._source.getLanguageId(this._firstTokenIndex+e)}getLineContent(){return this._source.getLineContent().substring(this._startOffset,this._endOffset)}equals(e){return e instanceof r&&(this._startOffset===e._startOffset&&this._endOffset===e._endOffset&&this._deltaOffset===e._deltaOffset&&this._source.slicedEquals(e._source,this._firstTokenIndex,this._tokensCount))}getCount(){return this._tokensCount}getStandardTokenType(e){return this._source.getStandardTokenType(this._firstTokenIndex+e)}getForeground(e){return this._source.getForeground(this._firstTokenIndex+e)}getEndOffset(e){const t=this._source.getEndOffset(this._firstTokenIndex+e);return Math.min(this._endOffset,t)-this._startOffset+this._deltaOffset}getClassName(e){return this._source.getClassName(this._firstTokenIndex+e)}getInlineStyle(e,t){return this._source.getInlineStyle(this._firstTokenIndex+e,t)}getPresentation(e){return this._source.getPresentation(this._firstTokenIndex+e)}findTokenIndexAtOffset(e){return this._source.findTokenIndexAtOffset(e+this._startOffset-this._deltaOffset)-this._firstTokenIndex}getTokenText(e){const t=this._firstTokenIndex+e,i=this._source.getStartOffset(t),s=this._source.getEndOffset(t);let n=this._source.getTokenText(t);return ithis._endOffset&&(n=n.substring(0,n.length-(s-this._endOffset))),n}forEach(e){for(let t=0;t{"use strict";i.d(t,{WL:()=>c,q6:()=>u,wm:()=>d});var s=i(64383),n=i(86571),r=i(83069),o=i(36677),a=i(75295);class c{static inverse(e,t,i){const s=[];let r=1,o=1;for(const l of e){const e=new c(new n.M(r,l.original.startLineNumber),new n.M(o,l.modified.startLineNumber));e.modified.isEmpty||s.push(e),r=l.original.endLineNumberExclusive,o=l.modified.endLineNumberExclusive}const a=new c(new n.M(r,t+1),new n.M(o,i+1));return a.modified.isEmpty||s.push(a),s}static clip(e,t,i){const s=[];for(const n of e){const e=n.original.intersect(t),r=n.modified.intersect(i);e&&!e.isEmpty&&r&&!r.isEmpty&&s.push(new c(e,r))}return s}constructor(e,t){this.original=e,this.modified=t}toString(){return`{${this.original.toString()}->${this.modified.toString()}}`}flip(){return new c(this.modified,this.original)}join(e){return new c(this.original.join(e.original),this.modified.join(e.modified))}toRangeMapping(){const e=this.original.toInclusiveRange(),t=this.modified.toInclusiveRange();if(e&&t)return new u(e,t);if(1===this.original.startLineNumber||1===this.modified.startLineNumber){if(1!==this.modified.startLineNumber||1!==this.original.startLineNumber)throw new s.D7("not a valid diff");return new u(new o.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new o.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1))}return new u(new o.Q(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),new o.Q(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER))}toRangeMapping2(e,t){if(h(this.original.endLineNumberExclusive,e)&&h(this.modified.endLineNumberExclusive,t))return new u(new o.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new o.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1));if(!this.original.isEmpty&&!this.modified.isEmpty)return new u(o.Q.fromPositions(new r.y(this.original.startLineNumber,1),l(new r.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),o.Q.fromPositions(new r.y(this.modified.startLineNumber,1),l(new r.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));if(this.original.startLineNumber>1&&this.modified.startLineNumber>1)return new u(o.Q.fromPositions(l(new r.y(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER),e),l(new r.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),o.Q.fromPositions(l(new r.y(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER),t),l(new r.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));throw new s.D7}}function l(e,t){if(e.lineNumber<1)return new r.y(1,1);if(e.lineNumber>t.length)return new r.y(t.length,t[t.length-1].length+1);const i=t[e.lineNumber-1];return e.column>i.length+1?new r.y(e.lineNumber,i.length+1):e}function h(e,t){return e>=1&&e<=t.length}class d extends c{static fromRangeMappings(e){const t=n.M.join(e.map((e=>n.M.fromRangeInclusive(e.originalRange)))),i=n.M.join(e.map((e=>n.M.fromRangeInclusive(e.modifiedRange))));return new d(t,i,e)}constructor(e,t,i){super(e,t),this.innerChanges=i}flip(){return new d(this.modified,this.original,this.innerChanges?.map((e=>e.flip())))}withInnerChangesFromLineRanges(){return new d(this.original,this.modified,[this.toRangeMapping()])}}class u{static assertSorted(e){for(let t=1;t${this.modifiedRange.toString()}}`}flip(){return new u(this.modifiedRange,this.originalRange)}toTextEdit(e){const t=e.getValueOfRange(this.modifiedRange);return new a.WR(this.originalRange,t)}}},87758:(e,t,i)=>{"use strict";i.d(t,{G8:()=>_,Hm:()=>d,Hp:()=>a,K6:()=>o,MB:()=>c,Xp:()=>u,Zp:()=>f,dV:()=>r,iM:()=>m,ih:()=>h,jA:()=>n,jq:()=>p,vf:()=>l,vx:()=>g});var s=i(78209);const n="editor.action.showHover",r="editor.action.showDefinitionPreviewHover",o="editor.action.scrollUpHover",a="editor.action.scrollDownHover",c="editor.action.scrollLeftHover",l="editor.action.scrollRightHover",h="editor.action.pageUpHover",d="editor.action.pageDownHover",u="editor.action.goToTopHover",g="editor.action.goToBottomHover",p="editor.action.increaseHoverVerbosityLevel",m=s.kg({key:"increaseHoverVerbosityLevel",comment:["Label for action that will increase the hover verbosity level."]},"Increase Hover Verbosity Level"),f="editor.action.decreaseHoverVerbosityLevel",_=s.kg({key:"decreaseHoverVerbosityLevel",comment:["Label for action that will decrease the hover verbosity level."]},"Decrease Hover Verbosity Level")},87784:(e,t,i)=>{"use strict";i.d(t,{M:()=>a});var s=i(64383),n=i(5662),r=i(44026);const o={};class a{constructor(e,t,i,s,r){this.editorModel=e,this.providers=t,this.handleFoldingRangesChange=i,this.foldingRangesLimit=s,this.fallbackRangeProvider=r,this.id="syntax",this.disposables=new n.Cm,r&&this.disposables.add(r);for(const n of t)"function"===typeof n.onDidChange&&this.disposables.add(n.onDidChange(i))}compute(e){return function(e,t,i){let n=null;const r=e.map(((e,r)=>Promise.resolve(e.provideFoldingRanges(t,o,i)).then((e=>{if(!i.isCancellationRequested&&Array.isArray(e)){Array.isArray(n)||(n=[]);const i=t.getLineCount();for(const t of e)t.start>0&&t.end>t.start&&t.end<=i&&n.push({start:t.start,end:t.end,rank:r,kind:t.kind})}}),s.M_)));return Promise.all(r).then((e=>n))}(this.providers,this.editorModel,e).then((t=>{if(t){return function(e,t){const i=e.sort(((e,t)=>{let i=e.start-t.start;return 0===i&&(i=e.rank-t.rank),i})),s=new c(t);let n;const r=[];for(const o of i)if(n){if(o.start>n.start)if(o.end<=n.end)r.push(n),n=o,s.add(o.start,o.end,o.kind&&o.kind.value,r.length);else{if(o.start>n.end){do{n=r.pop()}while(n&&o.start>n.end);n&&r.push(n),n=o}s.add(o.start,o.end,o.kind&&o.kind.value,r.length)}}else n=o,s.add(o.start,o.end,o.kind&&o.kind.value,r.length);return s.toIndentRanges()}(t,this.foldingRangesLimit)}return this.fallbackRangeProvider?.compute(e)??null}))}dispose(){this.disposables.dispose()}}class c{constructor(e){this._startIndexes=[],this._endIndexes=[],this._nestingLevels=[],this._nestingLevelCounts=[],this._types=[],this._length=0,this._foldingRangesLimit=e}add(e,t,i,s){if(e>r.yy||t>r.yy)return;const n=this._length;this._startIndexes[n]=e,this._endIndexes[n]=t,this._nestingLevels[n]=s,this._types[n]=i,this._length++,s<30&&(this._nestingLevelCounts[s]=(this._nestingLevelCounts[s]||0)+1)}toIndentRanges(){const e=this._foldingRangesLimit.limit;if(this._length<=e){this._foldingRangesLimit.update(this._length,!1);const e=new Uint32Array(this._length),t=new Uint32Array(this._length);for(let i=0;ie){i=r;break}t+=s}}const s=new Uint32Array(e),n=new Uint32Array(e),o=[];for(let r=0,a=0;r{"use strict";i.d(t,{$C:()=>O,BE:()=>H,Bc:()=>k,O4:()=>w,Of:()=>P,XR:()=>M,hZ:()=>g,jT:()=>x,jU:()=>U,ls:()=>b,lw:()=>h,m9:()=>T,n0:()=>d,qB:()=>W,r_:()=>A,wA:()=>C,xZ:()=>I,xq:()=>l,zM:()=>_});var s=i(25890),n=i(10146),r=i(98067),o=i(24329),a=i(26486),c=i(78209);const l=8;class h{constructor(e){this._values=e}hasChanged(e){return this._values[e]}}class d{constructor(){this.stableMinimapLayoutInput=null,this.stableFitMaxMinimapScale=0,this.stableFitRemainingWidth=0}}class u{constructor(e,t,i,s){this.id=e,this.name=t,this.defaultValue=i,this.schema=s}applyUpdate(e,t){return p(e,t)}compute(e,t,i){return i}}class g{constructor(e,t){this.newValue=e,this.didChange=t}}function p(e,t){if("object"!==typeof e||"object"!==typeof t||!e||!t)return new g(t,e!==t);if(Array.isArray(e)||Array.isArray(t)){const i=Array.isArray(e)&&Array.isArray(t)&&s.aI(e,t);return new g(t,!i)}let i=!1;for(const s in t)if(t.hasOwnProperty(s)){const n=p(e[s],t[s]);n.didChange&&(e[s]=n.newValue,i=!0)}return new g(e,i)}class m{constructor(e){this.schema=void 0,this.id=e,this.name="_never_",this.defaultValue=void 0}applyUpdate(e,t){return p(e,t)}validate(e){return this.defaultValue}}class f{constructor(e,t,i,s){this.id=e,this.name=t,this.defaultValue=i,this.schema=s}applyUpdate(e,t){return p(e,t)}validate(e){return"undefined"===typeof e?this.defaultValue:e}compute(e,t,i){return i}}function _(e,t){return"undefined"===typeof e?t:"false"!==e&&Boolean(e)}class v extends f{constructor(e,t,i,s=void 0){"undefined"!==typeof s&&(s.type="boolean",s.default=i),super(e,t,i,s)}validate(e){return _(e,this.defaultValue)}}function C(e,t,i,s){if("undefined"===typeof e)return t;let n=parseInt(e,10);return isNaN(n)?t:(n=Math.max(i,n),n=Math.min(s,n),0|n)}class E extends f{static clampedInt(e,t,i,s){return C(e,t,i,s)}constructor(e,t,i,s,n,r=void 0){"undefined"!==typeof r&&(r.type="integer",r.default=i,r.minimum=s,r.maximum=n),super(e,t,i,r),this.minimum=s,this.maximum=n}validate(e){return E.clampedInt(e,this.defaultValue,this.minimum,this.maximum)}}function b(e,t,i,s){if("undefined"===typeof e)return t;const n=S.float(e,t);return S.clamp(n,i,s)}class S extends f{static clamp(e,t,i){return ei?i:e}static float(e,t){if("number"===typeof e)return e;if("undefined"===typeof e)return t;const i=parseFloat(e);return isNaN(i)?t:i}constructor(e,t,i,s,n){"undefined"!==typeof n&&(n.type="number",n.default=i),super(e,t,i,n),this.validationFn=s}validate(e){return this.validationFn(S.float(e,this.defaultValue))}}class y extends f{static string(e,t){return"string"!==typeof e?t:e}constructor(e,t,i,s=void 0){"undefined"!==typeof s&&(s.type="string",s.default=i),super(e,t,i,s)}validate(e){return y.string(e,this.defaultValue)}}function w(e,t,i,s){return"string"!==typeof e?t:s&&e in s?s[e]:-1===i.indexOf(e)?t:e}class R extends f{constructor(e,t,i,s,n=void 0){"undefined"!==typeof n&&(n.type="string",n.enum=s,n.default=i),super(e,t,i,n),this._allowedValues=s}validate(e){return w(e,this.defaultValue,this._allowedValues)}}class L extends u{constructor(e,t,i,s,n,r,o=void 0){"undefined"!==typeof o&&(o.type="string",o.enum=n,o.default=s),super(e,t,i,o),this._allowedValues=n,this._convert=r}validate(e){return"string"!==typeof e||-1===this._allowedValues.indexOf(e)?this.defaultValue:this._convert(e)}}var T,x;!function(e){e[e.Line=1]="Line",e[e.Block=2]="Block",e[e.Underline=3]="Underline",e[e.LineThin=4]="LineThin",e[e.BlockOutline=5]="BlockOutline",e[e.UnderlineThin=6]="UnderlineThin"}(T||(T={}));class k extends u{static{this.OFF='"liga" off, "calt" off'}static{this.ON='"liga" on, "calt" on'}constructor(){super(51,"fontLigatures",k.OFF,{anyOf:[{type:"boolean",description:c.kg("fontLigatures","Enables/Disables font ligatures ('calt' and 'liga' font features). Change this to a string for fine-grained control of the 'font-feature-settings' CSS property.")},{type:"string",description:c.kg("fontFeatureSettings","Explicit 'font-feature-settings' CSS property. A boolean can be passed instead if one only needs to turn on/off ligatures.")}],description:c.kg("fontLigaturesGeneral","Configures font ligatures or font features. Can be either a boolean to enable/disable ligatures or a string for the value of the CSS 'font-feature-settings' property."),default:!1})}validate(e){return"undefined"===typeof e?this.defaultValue:"string"===typeof e?"false"===e||0===e.length?k.OFF:"true"===e?k.ON:e:Boolean(e)?k.ON:k.OFF}}class A extends u{static{this.OFF="normal"}static{this.TRANSLATE="translate"}constructor(){super(54,"fontVariations",A.OFF,{anyOf:[{type:"boolean",description:c.kg("fontVariations","Enables/Disables the translation from font-weight to font-variation-settings. Change this to a string for fine-grained control of the 'font-variation-settings' CSS property.")},{type:"string",description:c.kg("fontVariationSettings","Explicit 'font-variation-settings' CSS property. A boolean can be passed instead if one only needs to translate font-weight to font-variation-settings.")}],description:c.kg("fontVariationsGeneral","Configures font variations. Can be either a boolean to enable/disable the translation from font-weight to font-variation-settings or a string for the value of the CSS 'font-variation-settings' property."),default:!1})}validate(e){return"undefined"===typeof e?this.defaultValue:"string"===typeof e?"false"===e?A.OFF:"true"===e?A.TRANSLATE:e:Boolean(e)?A.TRANSLATE:A.OFF}compute(e,t,i){return e.fontInfo.fontVariationSettings}}class N extends u{static{this.SUGGESTION_VALUES=["normal","bold","100","200","300","400","500","600","700","800","900"]}static{this.MINIMUM_VALUE=1}static{this.MAXIMUM_VALUE=1e3}constructor(){super(53,"fontWeight",U.fontWeight,{anyOf:[{type:"number",minimum:N.MINIMUM_VALUE,maximum:N.MAXIMUM_VALUE,errorMessage:c.kg("fontWeightErrorMessage",'Only "normal" and "bold" keywords or numbers between 1 and 1000 are allowed.')},{type:"string",pattern:"^(normal|bold|1000|[1-9][0-9]{0,2})$"},{enum:N.SUGGESTION_VALUES}],default:U.fontWeight,description:c.kg("fontWeight",'Controls the font weight. Accepts "normal" and "bold" keywords or numbers between 1 and 1000.')})}validate(e){return"normal"===e||"bold"===e?e:String(E.clampedInt(e,U.fontWeight,N.MINIMUM_VALUE,N.MAXIMUM_VALUE))}}class I extends m{constructor(){super(146)}compute(e,t,i){return I.computeLayout(t,{memory:e.memory,outerWidth:e.outerWidth,outerHeight:e.outerHeight,isDominatedByLongLines:e.isDominatedByLongLines,lineHeight:e.fontInfo.lineHeight,viewLineCount:e.viewLineCount,lineNumbersDigitCount:e.lineNumbersDigitCount,typicalHalfwidthCharacterWidth:e.fontInfo.typicalHalfwidthCharacterWidth,maxDigitWidth:e.fontInfo.maxDigitWidth,pixelRatio:e.pixelRatio,glyphMarginDecorationLaneCount:e.glyphMarginDecorationLaneCount})}static computeContainedMinimapLineCount(e){const t=e.height/e.lineHeight,i=Math.floor(e.paddingTop/e.lineHeight);let s=Math.floor(e.paddingBottom/e.lineHeight);e.scrollBeyondLastLine&&(s=Math.max(s,t-1));const n=(i+e.viewLineCount+s)/(e.pixelRatio*e.height);return{typicalViewportLineCount:t,extraLinesBeforeFirstLine:i,extraLinesBeyondLastLine:s,desiredRatio:n,minimapLineCount:Math.floor(e.viewLineCount/n)}}static _computeMinimapLayout(e,t){const i=e.outerWidth,s=e.outerHeight,n=e.pixelRatio;if(!e.minimap.enabled)return{renderMinimap:0,minimapLeft:0,minimapWidth:0,minimapHeightIsEditorHeight:!1,minimapIsSampling:!1,minimapScale:1,minimapLineHeight:1,minimapCanvasInnerWidth:0,minimapCanvasInnerHeight:Math.floor(n*s),minimapCanvasOuterWidth:0,minimapCanvasOuterHeight:s};const r=t.stableMinimapLayoutInput,o=r&&e.outerHeight===r.outerHeight&&e.lineHeight===r.lineHeight&&e.typicalHalfwidthCharacterWidth===r.typicalHalfwidthCharacterWidth&&e.pixelRatio===r.pixelRatio&&e.scrollBeyondLastLine===r.scrollBeyondLastLine&&e.paddingTop===r.paddingTop&&e.paddingBottom===r.paddingBottom&&e.minimap.enabled===r.minimap.enabled&&e.minimap.side===r.minimap.side&&e.minimap.size===r.minimap.size&&e.minimap.showSlider===r.minimap.showSlider&&e.minimap.renderCharacters===r.minimap.renderCharacters&&e.minimap.maxColumn===r.minimap.maxColumn&&e.minimap.scale===r.minimap.scale&&e.verticalScrollbarWidth===r.verticalScrollbarWidth&&e.isViewportWrapping===r.isViewportWrapping,a=e.lineHeight,c=e.typicalHalfwidthCharacterWidth,h=e.scrollBeyondLastLine,d=e.minimap.renderCharacters;let u=n>=2?Math.round(2*e.minimap.scale):e.minimap.scale;const g=e.minimap.maxColumn,p=e.minimap.size,m=e.minimap.side,f=e.verticalScrollbarWidth,_=e.viewLineCount,v=e.remainingWidth,C=e.isViewportWrapping,E=d?2:3;let b=Math.floor(n*s);const S=b/n;let y=!1,w=!1,R=E*u,L=u/n,T=1;if("fill"===p||"fit"===p){const{typicalViewportLineCount:i,extraLinesBeforeFirstLine:r,extraLinesBeyondLastLine:c,desiredRatio:l,minimapLineCount:d}=I.computeContainedMinimapLineCount({viewLineCount:_,scrollBeyondLastLine:h,paddingTop:e.paddingTop,paddingBottom:e.paddingBottom,height:s,lineHeight:a,pixelRatio:n});if(_/d>1)y=!0,w=!0,u=1,R=1,L=u/n;else{let s=!1,h=u+1;if("fit"===p){const e=Math.ceil((r+_+c)*R);C&&o&&v<=t.stableFitRemainingWidth?(s=!0,h=t.stableFitMaxMinimapScale):s=e>b}if("fill"===p||s){y=!0;const s=u;R=Math.min(a*n,Math.max(1,Math.floor(1/l))),C&&o&&v<=t.stableFitRemainingWidth&&(h=t.stableFitMaxMinimapScale),u=Math.min(h,Math.max(1,Math.floor(R/E))),u>s&&(T=Math.min(2,u/s)),L=u/n/T,b=Math.ceil(Math.max(i,r+_+c)*R),C?(t.stableMinimapLayoutInput=e,t.stableFitRemainingWidth=v,t.stableFitMaxMinimapScale=u):(t.stableMinimapLayoutInput=null,t.stableFitRemainingWidth=0)}}}const x=Math.floor(g*L),k=Math.min(x,Math.max(0,Math.floor((v-f-2)*L/(c+L)))+l);let A=Math.floor(n*k);const N=A/n;A=Math.floor(A*T);return{renderMinimap:d?1:2,minimapLeft:"left"===m?0:i-k-f,minimapWidth:k,minimapHeightIsEditorHeight:y,minimapIsSampling:w,minimapScale:u,minimapLineHeight:R,minimapCanvasInnerWidth:A,minimapCanvasInnerHeight:b,minimapCanvasOuterWidth:N,minimapCanvasOuterHeight:S}}static computeLayout(e,t){const i=0|t.outerWidth,s=0|t.outerHeight,n=0|t.lineHeight,r=0|t.lineNumbersDigitCount,o=t.typicalHalfwidthCharacterWidth,a=t.maxDigitWidth,c=t.pixelRatio,l=t.viewLineCount,h=e.get(138),u="inherit"===h?e.get(137):h,g="inherit"===u?e.get(133):u,p=e.get(136),m=t.isDominatedByLongLines,f=e.get(57),_=0!==e.get(68).renderType,v=e.get(69),C=e.get(106),E=e.get(84),b=e.get(73),S=e.get(104),y=S.verticalScrollbarSize,w=S.verticalHasArrows,R=S.arrowSize,L=S.horizontalScrollbarSize,T=e.get(43),x="never"!==e.get(111);let k=e.get(66);T&&x&&(k+=16);let A=0;if(_){const e=Math.max(r,v);A=Math.round(e*a)}let N=0;f&&(N=n*t.glyphMarginDecorationLaneCount);let O=0,D=O+N,M=D+A,P=M+k;const F=i-N-A-k;let U=!1,H=!1,B=-1;"inherit"===u&&m?(U=!0,H=!0):"on"===g||"bounded"===g?H=!0:"wordWrapColumn"===g&&(B=p);const W=I._computeMinimapLayout({outerWidth:i,outerHeight:s,lineHeight:n,typicalHalfwidthCharacterWidth:o,pixelRatio:c,scrollBeyondLastLine:C,paddingTop:E.top,paddingBottom:E.bottom,minimap:b,verticalScrollbarWidth:y,viewLineCount:l,remainingWidth:F,isViewportWrapping:H},t.memory||new d);0!==W.renderMinimap&&0===W.minimapLeft&&(O+=W.minimapWidth,D+=W.minimapWidth,M+=W.minimapWidth,P+=W.minimapWidth);const V=F-W.minimapWidth,z=Math.max(1,Math.floor((V-y-2)/o)),G=w?R:0;return H&&(B=Math.max(1,z),"bounded"===g&&(B=Math.min(B,p))),{width:i,height:s,glyphMarginLeft:O,glyphMarginWidth:N,glyphMarginDecorationLaneCount:t.glyphMarginDecorationLaneCount,lineNumbersLeft:D,lineNumbersWidth:A,decorationsLeft:M,decorationsWidth:k,contentLeft:P,contentWidth:V,minimap:W,viewportColumn:z,isWordWrapMinified:U,isViewportWrapping:H,wrappingColumn:B,verticalScrollbarWidth:y,horizontalScrollbarHeight:L,overviewRuler:{top:G,width:y,height:s-2*G,right:0}}}}!function(e){e.Off="off",e.OnCode="onCode",e.On="on"}(x||(x={}));function O(e){const t=e.get(99);return"editable"===t?e.get(92):"on"!==t}function D(e,t){if("string"!==typeof e)return t;switch(e){case"hidden":return 2;case"visible":return 3;default:return 1}}const M="inUntrustedWorkspace",P={allowedCharacters:"editor.unicodeHighlight.allowedCharacters",invisibleCharacters:"editor.unicodeHighlight.invisibleCharacters",nonBasicASCII:"editor.unicodeHighlight.nonBasicASCII",ambiguousCharacters:"editor.unicodeHighlight.ambiguousCharacters",includeComments:"editor.unicodeHighlight.includeComments",includeStrings:"editor.unicodeHighlight.includeStrings",allowedLocales:"editor.unicodeHighlight.allowedLocales"};function F(e,t,i){const s=i.indexOf(e);return-1===s?t:i[s]}const U={fontFamily:r.zx?"Menlo, Monaco, 'Courier New', monospace":r.j9?"'Droid Sans Mono', 'monospace', monospace":"Consolas, 'Courier New', monospace",fontWeight:"normal",fontSize:r.zx?12:14,lineHeight:0,letterSpacing:0},H=[];function B(e){return H[e.id]=e,e}const W={acceptSuggestionOnCommitCharacter:B(new v(0,"acceptSuggestionOnCommitCharacter",!0,{markdownDescription:c.kg("acceptSuggestionOnCommitCharacter","Controls whether suggestions should be accepted on commit characters. For example, in JavaScript, the semi-colon (`;`) can be a commit character that accepts a suggestion and types that character.")})),acceptSuggestionOnEnter:B(new R(1,"acceptSuggestionOnEnter","on",["on","smart","off"],{markdownEnumDescriptions:["",c.kg("acceptSuggestionOnEnterSmart","Only accept a suggestion with `Enter` when it makes a textual change."),""],markdownDescription:c.kg("acceptSuggestionOnEnter","Controls whether suggestions should be accepted on `Enter`, in addition to `Tab`. Helps to avoid ambiguity between inserting new lines or accepting suggestions.")})),accessibilitySupport:B(new class extends u{constructor(){super(2,"accessibilitySupport",0,{type:"string",enum:["auto","on","off"],enumDescriptions:[c.kg("accessibilitySupport.auto","Use platform APIs to detect when a Screen Reader is attached."),c.kg("accessibilitySupport.on","Optimize for usage with a Screen Reader."),c.kg("accessibilitySupport.off","Assume a screen reader is not attached.")],default:"auto",tags:["accessibility"],description:c.kg("accessibilitySupport","Controls if the UI should run in a mode where it is optimized for screen readers.")})}validate(e){switch(e){case"auto":return 0;case"off":return 1;case"on":return 2}return this.defaultValue}compute(e,t,i){return 0===i?e.accessibilitySupport:i}}),accessibilityPageSize:B(new E(3,"accessibilityPageSize",10,1,1073741824,{description:c.kg("accessibilityPageSize","Controls the number of lines in the editor that can be read out by a screen reader at once. When we detect a screen reader we automatically set the default to be 500. Warning: this has a performance implication for numbers larger than the default."),tags:["accessibility"]})),ariaLabel:B(new y(4,"ariaLabel",c.kg("editorViewAccessibleLabel","Editor content"))),ariaRequired:B(new v(5,"ariaRequired",!1,void 0)),screenReaderAnnounceInlineSuggestion:B(new v(8,"screenReaderAnnounceInlineSuggestion",!0,{description:c.kg("screenReaderAnnounceInlineSuggestion","Control whether inline suggestions are announced by a screen reader."),tags:["accessibility"]})),autoClosingBrackets:B(new R(6,"autoClosingBrackets","languageDefined",["always","languageDefined","beforeWhitespace","never"],{enumDescriptions:["",c.kg("editor.autoClosingBrackets.languageDefined","Use language configurations to determine when to autoclose brackets."),c.kg("editor.autoClosingBrackets.beforeWhitespace","Autoclose brackets only when the cursor is to the left of whitespace."),""],description:c.kg("autoClosingBrackets","Controls whether the editor should automatically close brackets after the user adds an opening bracket.")})),autoClosingComments:B(new R(7,"autoClosingComments","languageDefined",["always","languageDefined","beforeWhitespace","never"],{enumDescriptions:["",c.kg("editor.autoClosingComments.languageDefined","Use language configurations to determine when to autoclose comments."),c.kg("editor.autoClosingComments.beforeWhitespace","Autoclose comments only when the cursor is to the left of whitespace."),""],description:c.kg("autoClosingComments","Controls whether the editor should automatically close comments after the user adds an opening comment.")})),autoClosingDelete:B(new R(9,"autoClosingDelete","auto",["always","auto","never"],{enumDescriptions:["",c.kg("editor.autoClosingDelete.auto","Remove adjacent closing quotes or brackets only if they were automatically inserted."),""],description:c.kg("autoClosingDelete","Controls whether the editor should remove adjacent closing quotes or brackets when deleting.")})),autoClosingOvertype:B(new R(10,"autoClosingOvertype","auto",["always","auto","never"],{enumDescriptions:["",c.kg("editor.autoClosingOvertype.auto","Type over closing quotes or brackets only if they were automatically inserted."),""],description:c.kg("autoClosingOvertype","Controls whether the editor should type over closing quotes or brackets.")})),autoClosingQuotes:B(new R(11,"autoClosingQuotes","languageDefined",["always","languageDefined","beforeWhitespace","never"],{enumDescriptions:["",c.kg("editor.autoClosingQuotes.languageDefined","Use language configurations to determine when to autoclose quotes."),c.kg("editor.autoClosingQuotes.beforeWhitespace","Autoclose quotes only when the cursor is to the left of whitespace."),""],description:c.kg("autoClosingQuotes","Controls whether the editor should automatically close quotes after the user adds an opening quote.")})),autoIndent:B(new L(12,"autoIndent",4,"full",["none","keep","brackets","advanced","full"],(function(e){switch(e){case"none":return 0;case"keep":return 1;case"brackets":return 2;case"advanced":return 3;case"full":return 4}}),{enumDescriptions:[c.kg("editor.autoIndent.none","The editor will not insert indentation automatically."),c.kg("editor.autoIndent.keep","The editor will keep the current line's indentation."),c.kg("editor.autoIndent.brackets","The editor will keep the current line's indentation and honor language defined brackets."),c.kg("editor.autoIndent.advanced","The editor will keep the current line's indentation, honor language defined brackets and invoke special onEnterRules defined by languages."),c.kg("editor.autoIndent.full","The editor will keep the current line's indentation, honor language defined brackets, invoke special onEnterRules defined by languages, and honor indentationRules defined by languages.")],description:c.kg("autoIndent","Controls whether the editor should automatically adjust the indentation when users type, paste, move or indent lines.")})),automaticLayout:B(new v(13,"automaticLayout",!1)),autoSurround:B(new R(14,"autoSurround","languageDefined",["languageDefined","quotes","brackets","never"],{enumDescriptions:[c.kg("editor.autoSurround.languageDefined","Use language configurations to determine when to automatically surround selections."),c.kg("editor.autoSurround.quotes","Surround with quotes but not brackets."),c.kg("editor.autoSurround.brackets","Surround with brackets but not quotes."),""],description:c.kg("autoSurround","Controls whether the editor should automatically surround selections when typing quotes or brackets.")})),bracketPairColorization:B(new class extends u{constructor(){const e={enabled:o.R.bracketPairColorizationOptions.enabled,independentColorPoolPerBracketType:o.R.bracketPairColorizationOptions.independentColorPoolPerBracketType};super(15,"bracketPairColorization",e,{"editor.bracketPairColorization.enabled":{type:"boolean",default:e.enabled,markdownDescription:c.kg("bracketPairColorization.enabled","Controls whether bracket pair colorization is enabled or not. Use {0} to override the bracket highlight colors.","`#workbench.colorCustomizations#`")},"editor.bracketPairColorization.independentColorPoolPerBracketType":{type:"boolean",default:e.independentColorPoolPerBracketType,description:c.kg("bracketPairColorization.independentColorPoolPerBracketType","Controls whether each bracket type has its own independent color pool.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),independentColorPoolPerBracketType:_(t.independentColorPoolPerBracketType,this.defaultValue.independentColorPoolPerBracketType)}}}),bracketPairGuides:B(new class extends u{constructor(){const e={bracketPairs:!1,bracketPairsHorizontal:"active",highlightActiveBracketPair:!0,indentation:!0,highlightActiveIndentation:!0};super(16,"guides",e,{"editor.guides.bracketPairs":{type:["boolean","string"],enum:[!0,"active",!1],enumDescriptions:[c.kg("editor.guides.bracketPairs.true","Enables bracket pair guides."),c.kg("editor.guides.bracketPairs.active","Enables bracket pair guides only for the active bracket pair."),c.kg("editor.guides.bracketPairs.false","Disables bracket pair guides.")],default:e.bracketPairs,description:c.kg("editor.guides.bracketPairs","Controls whether bracket pair guides are enabled or not.")},"editor.guides.bracketPairsHorizontal":{type:["boolean","string"],enum:[!0,"active",!1],enumDescriptions:[c.kg("editor.guides.bracketPairsHorizontal.true","Enables horizontal guides as addition to vertical bracket pair guides."),c.kg("editor.guides.bracketPairsHorizontal.active","Enables horizontal guides only for the active bracket pair."),c.kg("editor.guides.bracketPairsHorizontal.false","Disables horizontal bracket pair guides.")],default:e.bracketPairsHorizontal,description:c.kg("editor.guides.bracketPairsHorizontal","Controls whether horizontal bracket pair guides are enabled or not.")},"editor.guides.highlightActiveBracketPair":{type:"boolean",default:e.highlightActiveBracketPair,description:c.kg("editor.guides.highlightActiveBracketPair","Controls whether the editor should highlight the active bracket pair.")},"editor.guides.indentation":{type:"boolean",default:e.indentation,description:c.kg("editor.guides.indentation","Controls whether the editor should render indent guides.")},"editor.guides.highlightActiveIndentation":{type:["boolean","string"],enum:[!0,"always",!1],enumDescriptions:[c.kg("editor.guides.highlightActiveIndentation.true","Highlights the active indent guide."),c.kg("editor.guides.highlightActiveIndentation.always","Highlights the active indent guide even if bracket guides are highlighted."),c.kg("editor.guides.highlightActiveIndentation.false","Do not highlight the active indent guide.")],default:e.highlightActiveIndentation,description:c.kg("editor.guides.highlightActiveIndentation","Controls whether the editor should highlight the active indent guide.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{bracketPairs:F(t.bracketPairs,this.defaultValue.bracketPairs,[!0,!1,"active"]),bracketPairsHorizontal:F(t.bracketPairsHorizontal,this.defaultValue.bracketPairsHorizontal,[!0,!1,"active"]),highlightActiveBracketPair:_(t.highlightActiveBracketPair,this.defaultValue.highlightActiveBracketPair),indentation:_(t.indentation,this.defaultValue.indentation),highlightActiveIndentation:F(t.highlightActiveIndentation,this.defaultValue.highlightActiveIndentation,[!0,!1,"always"])}}}),stickyTabStops:B(new v(117,"stickyTabStops",!1,{description:c.kg("stickyTabStops","Emulate selection behavior of tab characters when using spaces for indentation. Selection will stick to tab stops.")})),codeLens:B(new v(17,"codeLens",!0,{description:c.kg("codeLens","Controls whether the editor shows CodeLens.")})),codeLensFontFamily:B(new y(18,"codeLensFontFamily","",{description:c.kg("codeLensFontFamily","Controls the font family for CodeLens.")})),codeLensFontSize:B(new E(19,"codeLensFontSize",0,0,100,{type:"number",default:0,minimum:0,maximum:100,markdownDescription:c.kg("codeLensFontSize","Controls the font size in pixels for CodeLens. When set to 0, 90% of `#editor.fontSize#` is used.")})),colorDecorators:B(new v(20,"colorDecorators",!0,{description:c.kg("colorDecorators","Controls whether the editor should render the inline color decorators and color picker.")})),colorDecoratorActivatedOn:B(new R(149,"colorDecoratorsActivatedOn","clickAndHover",["clickAndHover","hover","click"],{enumDescriptions:[c.kg("editor.colorDecoratorActivatedOn.clickAndHover","Make the color picker appear both on click and hover of the color decorator"),c.kg("editor.colorDecoratorActivatedOn.hover","Make the color picker appear on hover of the color decorator"),c.kg("editor.colorDecoratorActivatedOn.click","Make the color picker appear on click of the color decorator")],description:c.kg("colorDecoratorActivatedOn","Controls the condition to make a color picker appear from a color decorator")})),colorDecoratorsLimit:B(new E(21,"colorDecoratorsLimit",500,1,1e6,{markdownDescription:c.kg("colorDecoratorsLimit","Controls the max number of color decorators that can be rendered in an editor at once.")})),columnSelection:B(new v(22,"columnSelection",!1,{description:c.kg("columnSelection","Enable that the selection with the mouse and keys is doing column selection.")})),comments:B(new class extends u{constructor(){const e={insertSpace:!0,ignoreEmptyLines:!0};super(23,"comments",e,{"editor.comments.insertSpace":{type:"boolean",default:e.insertSpace,description:c.kg("comments.insertSpace","Controls whether a space character is inserted when commenting.")},"editor.comments.ignoreEmptyLines":{type:"boolean",default:e.ignoreEmptyLines,description:c.kg("comments.ignoreEmptyLines","Controls if empty lines should be ignored with toggle, add or remove actions for line comments.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{insertSpace:_(t.insertSpace,this.defaultValue.insertSpace),ignoreEmptyLines:_(t.ignoreEmptyLines,this.defaultValue.ignoreEmptyLines)}}}),contextmenu:B(new v(24,"contextmenu",!0)),copyWithSyntaxHighlighting:B(new v(25,"copyWithSyntaxHighlighting",!0,{description:c.kg("copyWithSyntaxHighlighting","Controls whether syntax highlighting should be copied into the clipboard.")})),cursorBlinking:B(new L(26,"cursorBlinking",1,"blink",["blink","smooth","phase","expand","solid"],(function(e){switch(e){case"blink":return 1;case"smooth":return 2;case"phase":return 3;case"expand":return 4;case"solid":return 5}}),{description:c.kg("cursorBlinking","Control the cursor animation style.")})),cursorSmoothCaretAnimation:B(new R(27,"cursorSmoothCaretAnimation","off",["off","explicit","on"],{enumDescriptions:[c.kg("cursorSmoothCaretAnimation.off","Smooth caret animation is disabled."),c.kg("cursorSmoothCaretAnimation.explicit","Smooth caret animation is enabled only when the user moves the cursor with an explicit gesture."),c.kg("cursorSmoothCaretAnimation.on","Smooth caret animation is always enabled.")],description:c.kg("cursorSmoothCaretAnimation","Controls whether the smooth caret animation should be enabled.")})),cursorStyle:B(new L(28,"cursorStyle",T.Line,"line",["line","block","underline","line-thin","block-outline","underline-thin"],(function(e){switch(e){case"line":return T.Line;case"block":return T.Block;case"underline":return T.Underline;case"line-thin":return T.LineThin;case"block-outline":return T.BlockOutline;case"underline-thin":return T.UnderlineThin}}),{description:c.kg("cursorStyle","Controls the cursor style.")})),cursorSurroundingLines:B(new E(29,"cursorSurroundingLines",0,0,1073741824,{description:c.kg("cursorSurroundingLines","Controls the minimal number of visible leading lines (minimum 0) and trailing lines (minimum 1) surrounding the cursor. Known as 'scrollOff' or 'scrollOffset' in some other editors.")})),cursorSurroundingLinesStyle:B(new R(30,"cursorSurroundingLinesStyle","default",["default","all"],{enumDescriptions:[c.kg("cursorSurroundingLinesStyle.default","`cursorSurroundingLines` is enforced only when triggered via the keyboard or API."),c.kg("cursorSurroundingLinesStyle.all","`cursorSurroundingLines` is enforced always.")],markdownDescription:c.kg("cursorSurroundingLinesStyle","Controls when `#editor.cursorSurroundingLines#` should be enforced.")})),cursorWidth:B(new E(31,"cursorWidth",0,0,1073741824,{markdownDescription:c.kg("cursorWidth","Controls the width of the cursor when `#editor.cursorStyle#` is set to `line`.")})),disableLayerHinting:B(new v(32,"disableLayerHinting",!1)),disableMonospaceOptimizations:B(new v(33,"disableMonospaceOptimizations",!1)),domReadOnly:B(new v(34,"domReadOnly",!1)),dragAndDrop:B(new v(35,"dragAndDrop",!0,{description:c.kg("dragAndDrop","Controls whether the editor should allow moving selections via drag and drop.")})),emptySelectionClipboard:B(new class extends v{constructor(){super(37,"emptySelectionClipboard",!0,{description:c.kg("emptySelectionClipboard","Controls whether copying without a selection copies the current line.")})}compute(e,t,i){return i&&e.emptySelectionClipboard}}),dropIntoEditor:B(new class extends u{constructor(){const e={enabled:!0,showDropSelector:"afterDrop"};super(36,"dropIntoEditor",e,{"editor.dropIntoEditor.enabled":{type:"boolean",default:e.enabled,markdownDescription:c.kg("dropIntoEditor.enabled","Controls whether you can drag and drop a file into a text editor by holding down the `Shift` key (instead of opening the file in an editor).")},"editor.dropIntoEditor.showDropSelector":{type:"string",markdownDescription:c.kg("dropIntoEditor.showDropSelector","Controls if a widget is shown when dropping files into the editor. This widget lets you control how the file is dropped."),enum:["afterDrop","never"],enumDescriptions:[c.kg("dropIntoEditor.showDropSelector.afterDrop","Show the drop selector widget after a file is dropped into the editor."),c.kg("dropIntoEditor.showDropSelector.never","Never show the drop selector widget. Instead the default drop provider is always used.")],default:"afterDrop"}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),showDropSelector:w(t.showDropSelector,this.defaultValue.showDropSelector,["afterDrop","never"])}}}),stickyScroll:B(new class extends u{constructor(){const e={enabled:!0,maxLineCount:5,defaultModel:"outlineModel",scrollWithEditor:!0};super(116,"stickyScroll",e,{"editor.stickyScroll.enabled":{type:"boolean",default:e.enabled,description:c.kg("editor.stickyScroll.enabled","Shows the nested current scopes during the scroll at the top of the editor."),tags:["experimental"]},"editor.stickyScroll.maxLineCount":{type:"number",default:e.maxLineCount,minimum:1,maximum:20,description:c.kg("editor.stickyScroll.maxLineCount","Defines the maximum number of sticky lines to show.")},"editor.stickyScroll.defaultModel":{type:"string",enum:["outlineModel","foldingProviderModel","indentationModel"],default:e.defaultModel,description:c.kg("editor.stickyScroll.defaultModel","Defines the model to use for determining which lines to stick. If the outline model does not exist, it will fall back on the folding provider model which falls back on the indentation model. This order is respected in all three cases.")},"editor.stickyScroll.scrollWithEditor":{type:"boolean",default:e.scrollWithEditor,description:c.kg("editor.stickyScroll.scrollWithEditor","Enable scrolling of Sticky Scroll with the editor's horizontal scrollbar.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),maxLineCount:E.clampedInt(t.maxLineCount,this.defaultValue.maxLineCount,1,20),defaultModel:w(t.defaultModel,this.defaultValue.defaultModel,["outlineModel","foldingProviderModel","indentationModel"]),scrollWithEditor:_(t.scrollWithEditor,this.defaultValue.scrollWithEditor)}}}),experimentalWhitespaceRendering:B(new R(38,"experimentalWhitespaceRendering","svg",["svg","font","off"],{enumDescriptions:[c.kg("experimentalWhitespaceRendering.svg","Use a new rendering method with svgs."),c.kg("experimentalWhitespaceRendering.font","Use a new rendering method with font characters."),c.kg("experimentalWhitespaceRendering.off","Use the stable rendering method.")],description:c.kg("experimentalWhitespaceRendering","Controls whether whitespace is rendered with a new, experimental method.")})),extraEditorClassName:B(new y(39,"extraEditorClassName","")),fastScrollSensitivity:B(new S(40,"fastScrollSensitivity",5,(e=>e<=0?5:e),{markdownDescription:c.kg("fastScrollSensitivity","Scrolling speed multiplier when pressing `Alt`.")})),find:B(new class extends u{constructor(){const e={cursorMoveOnType:!0,seedSearchStringFromSelection:"always",autoFindInSelection:"never",globalFindClipboard:!1,addExtraSpaceOnTop:!0,loop:!0};super(41,"find",e,{"editor.find.cursorMoveOnType":{type:"boolean",default:e.cursorMoveOnType,description:c.kg("find.cursorMoveOnType","Controls whether the cursor should jump to find matches while typing.")},"editor.find.seedSearchStringFromSelection":{type:"string",enum:["never","always","selection"],default:e.seedSearchStringFromSelection,enumDescriptions:[c.kg("editor.find.seedSearchStringFromSelection.never","Never seed search string from the editor selection."),c.kg("editor.find.seedSearchStringFromSelection.always","Always seed search string from the editor selection, including word at cursor position."),c.kg("editor.find.seedSearchStringFromSelection.selection","Only seed search string from the editor selection.")],description:c.kg("find.seedSearchStringFromSelection","Controls whether the search string in the Find Widget is seeded from the editor selection.")},"editor.find.autoFindInSelection":{type:"string",enum:["never","always","multiline"],default:e.autoFindInSelection,enumDescriptions:[c.kg("editor.find.autoFindInSelection.never","Never turn on Find in Selection automatically (default)."),c.kg("editor.find.autoFindInSelection.always","Always turn on Find in Selection automatically."),c.kg("editor.find.autoFindInSelection.multiline","Turn on Find in Selection automatically when multiple lines of content are selected.")],description:c.kg("find.autoFindInSelection","Controls the condition for turning on Find in Selection automatically.")},"editor.find.globalFindClipboard":{type:"boolean",default:e.globalFindClipboard,description:c.kg("find.globalFindClipboard","Controls whether the Find Widget should read or modify the shared find clipboard on macOS."),included:r.zx},"editor.find.addExtraSpaceOnTop":{type:"boolean",default:e.addExtraSpaceOnTop,description:c.kg("find.addExtraSpaceOnTop","Controls whether the Find Widget should add extra lines on top of the editor. When true, you can scroll beyond the first line when the Find Widget is visible.")},"editor.find.loop":{type:"boolean",default:e.loop,description:c.kg("find.loop","Controls whether the search automatically restarts from the beginning (or the end) when no further matches can be found.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{cursorMoveOnType:_(t.cursorMoveOnType,this.defaultValue.cursorMoveOnType),seedSearchStringFromSelection:"boolean"===typeof e.seedSearchStringFromSelection?e.seedSearchStringFromSelection?"always":"never":w(t.seedSearchStringFromSelection,this.defaultValue.seedSearchStringFromSelection,["never","always","selection"]),autoFindInSelection:"boolean"===typeof e.autoFindInSelection?e.autoFindInSelection?"always":"never":w(t.autoFindInSelection,this.defaultValue.autoFindInSelection,["never","always","multiline"]),globalFindClipboard:_(t.globalFindClipboard,this.defaultValue.globalFindClipboard),addExtraSpaceOnTop:_(t.addExtraSpaceOnTop,this.defaultValue.addExtraSpaceOnTop),loop:_(t.loop,this.defaultValue.loop)}}}),fixedOverflowWidgets:B(new v(42,"fixedOverflowWidgets",!1)),folding:B(new v(43,"folding",!0,{description:c.kg("folding","Controls whether the editor has code folding enabled.")})),foldingStrategy:B(new R(44,"foldingStrategy","auto",["auto","indentation"],{enumDescriptions:[c.kg("foldingStrategy.auto","Use a language-specific folding strategy if available, else the indentation-based one."),c.kg("foldingStrategy.indentation","Use the indentation-based folding strategy.")],description:c.kg("foldingStrategy","Controls the strategy for computing folding ranges.")})),foldingHighlight:B(new v(45,"foldingHighlight",!0,{description:c.kg("foldingHighlight","Controls whether the editor should highlight folded ranges.")})),foldingImportsByDefault:B(new v(46,"foldingImportsByDefault",!1,{description:c.kg("foldingImportsByDefault","Controls whether the editor automatically collapses import ranges.")})),foldingMaximumRegions:B(new E(47,"foldingMaximumRegions",5e3,10,65e3,{description:c.kg("foldingMaximumRegions","The maximum number of foldable regions. Increasing this value may result in the editor becoming less responsive when the current source has a large number of foldable regions.")})),unfoldOnClickAfterEndOfLine:B(new v(48,"unfoldOnClickAfterEndOfLine",!1,{description:c.kg("unfoldOnClickAfterEndOfLine","Controls whether clicking on the empty content after a folded line will unfold the line.")})),fontFamily:B(new y(49,"fontFamily",U.fontFamily,{description:c.kg("fontFamily","Controls the font family.")})),fontInfo:B(new class extends m{constructor(){super(50)}compute(e,t,i){return e.fontInfo}}),fontLigatures2:B(new k),fontSize:B(new class extends f{constructor(){super(52,"fontSize",U.fontSize,{type:"number",minimum:6,maximum:100,default:U.fontSize,description:c.kg("fontSize","Controls the font size in pixels.")})}validate(e){const t=S.float(e,this.defaultValue);return 0===t?U.fontSize:S.clamp(t,6,100)}compute(e,t,i){return e.fontInfo.fontSize}}),fontWeight:B(new N),fontVariations:B(new A),formatOnPaste:B(new v(55,"formatOnPaste",!1,{description:c.kg("formatOnPaste","Controls whether the editor should automatically format the pasted content. A formatter must be available and the formatter should be able to format a range in a document.")})),formatOnType:B(new v(56,"formatOnType",!1,{description:c.kg("formatOnType","Controls whether the editor should automatically format the line after typing.")})),glyphMargin:B(new v(57,"glyphMargin",!0,{description:c.kg("glyphMargin","Controls whether the editor should render the vertical glyph margin. Glyph margin is mostly used for debugging.")})),gotoLocation:B(new class extends u{constructor(){const e={multiple:"peek",multipleDefinitions:"peek",multipleTypeDefinitions:"peek",multipleDeclarations:"peek",multipleImplementations:"peek",multipleReferences:"peek",multipleTests:"peek",alternativeDefinitionCommand:"editor.action.goToReferences",alternativeTypeDefinitionCommand:"editor.action.goToReferences",alternativeDeclarationCommand:"editor.action.goToReferences",alternativeImplementationCommand:"",alternativeReferenceCommand:"",alternativeTestsCommand:""},t={type:"string",enum:["peek","gotoAndPeek","goto"],default:e.multiple,enumDescriptions:[c.kg("editor.gotoLocation.multiple.peek","Show Peek view of the results (default)"),c.kg("editor.gotoLocation.multiple.gotoAndPeek","Go to the primary result and show a Peek view"),c.kg("editor.gotoLocation.multiple.goto","Go to the primary result and enable Peek-less navigation to others")]},i=["","editor.action.referenceSearch.trigger","editor.action.goToReferences","editor.action.peekImplementation","editor.action.goToImplementation","editor.action.peekTypeDefinition","editor.action.goToTypeDefinition","editor.action.peekDeclaration","editor.action.revealDeclaration","editor.action.peekDefinition","editor.action.revealDefinitionAside","editor.action.revealDefinition"];super(58,"gotoLocation",e,{"editor.gotoLocation.multiple":{deprecationMessage:c.kg("editor.gotoLocation.multiple.deprecated","This setting is deprecated, please use separate settings like 'editor.editor.gotoLocation.multipleDefinitions' or 'editor.editor.gotoLocation.multipleImplementations' instead.")},"editor.gotoLocation.multipleDefinitions":{description:c.kg("editor.editor.gotoLocation.multipleDefinitions","Controls the behavior the 'Go to Definition'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleTypeDefinitions":{description:c.kg("editor.editor.gotoLocation.multipleTypeDefinitions","Controls the behavior the 'Go to Type Definition'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleDeclarations":{description:c.kg("editor.editor.gotoLocation.multipleDeclarations","Controls the behavior the 'Go to Declaration'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleImplementations":{description:c.kg("editor.editor.gotoLocation.multipleImplemenattions","Controls the behavior the 'Go to Implementations'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleReferences":{description:c.kg("editor.editor.gotoLocation.multipleReferences","Controls the behavior the 'Go to References'-command when multiple target locations exist."),...t},"editor.gotoLocation.alternativeDefinitionCommand":{type:"string",default:e.alternativeDefinitionCommand,enum:i,description:c.kg("alternativeDefinitionCommand","Alternative command id that is being executed when the result of 'Go to Definition' is the current location.")},"editor.gotoLocation.alternativeTypeDefinitionCommand":{type:"string",default:e.alternativeTypeDefinitionCommand,enum:i,description:c.kg("alternativeTypeDefinitionCommand","Alternative command id that is being executed when the result of 'Go to Type Definition' is the current location.")},"editor.gotoLocation.alternativeDeclarationCommand":{type:"string",default:e.alternativeDeclarationCommand,enum:i,description:c.kg("alternativeDeclarationCommand","Alternative command id that is being executed when the result of 'Go to Declaration' is the current location.")},"editor.gotoLocation.alternativeImplementationCommand":{type:"string",default:e.alternativeImplementationCommand,enum:i,description:c.kg("alternativeImplementationCommand","Alternative command id that is being executed when the result of 'Go to Implementation' is the current location.")},"editor.gotoLocation.alternativeReferenceCommand":{type:"string",default:e.alternativeReferenceCommand,enum:i,description:c.kg("alternativeReferenceCommand","Alternative command id that is being executed when the result of 'Go to Reference' is the current location.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{multiple:w(t.multiple,this.defaultValue.multiple,["peek","gotoAndPeek","goto"]),multipleDefinitions:t.multipleDefinitions??w(t.multipleDefinitions,"peek",["peek","gotoAndPeek","goto"]),multipleTypeDefinitions:t.multipleTypeDefinitions??w(t.multipleTypeDefinitions,"peek",["peek","gotoAndPeek","goto"]),multipleDeclarations:t.multipleDeclarations??w(t.multipleDeclarations,"peek",["peek","gotoAndPeek","goto"]),multipleImplementations:t.multipleImplementations??w(t.multipleImplementations,"peek",["peek","gotoAndPeek","goto"]),multipleReferences:t.multipleReferences??w(t.multipleReferences,"peek",["peek","gotoAndPeek","goto"]),multipleTests:t.multipleTests??w(t.multipleTests,"peek",["peek","gotoAndPeek","goto"]),alternativeDefinitionCommand:y.string(t.alternativeDefinitionCommand,this.defaultValue.alternativeDefinitionCommand),alternativeTypeDefinitionCommand:y.string(t.alternativeTypeDefinitionCommand,this.defaultValue.alternativeTypeDefinitionCommand),alternativeDeclarationCommand:y.string(t.alternativeDeclarationCommand,this.defaultValue.alternativeDeclarationCommand),alternativeImplementationCommand:y.string(t.alternativeImplementationCommand,this.defaultValue.alternativeImplementationCommand),alternativeReferenceCommand:y.string(t.alternativeReferenceCommand,this.defaultValue.alternativeReferenceCommand),alternativeTestsCommand:y.string(t.alternativeTestsCommand,this.defaultValue.alternativeTestsCommand)}}}),hideCursorInOverviewRuler:B(new v(59,"hideCursorInOverviewRuler",!1,{description:c.kg("hideCursorInOverviewRuler","Controls whether the cursor should be hidden in the overview ruler.")})),hover:B(new class extends u{constructor(){const e={enabled:!0,delay:300,hidingDelay:300,sticky:!0,above:!0};super(60,"hover",e,{"editor.hover.enabled":{type:"boolean",default:e.enabled,description:c.kg("hover.enabled","Controls whether the hover is shown.")},"editor.hover.delay":{type:"number",default:e.delay,minimum:0,maximum:1e4,description:c.kg("hover.delay","Controls the delay in milliseconds after which the hover is shown.")},"editor.hover.sticky":{type:"boolean",default:e.sticky,description:c.kg("hover.sticky","Controls whether the hover should remain visible when mouse is moved over it.")},"editor.hover.hidingDelay":{type:"integer",minimum:0,default:e.hidingDelay,description:c.kg("hover.hidingDelay","Controls the delay in milliseconds after which the hover is hidden. Requires `editor.hover.sticky` to be enabled.")},"editor.hover.above":{type:"boolean",default:e.above,description:c.kg("hover.above","Prefer showing hovers above the line, if there's space.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),delay:E.clampedInt(t.delay,this.defaultValue.delay,0,1e4),sticky:_(t.sticky,this.defaultValue.sticky),hidingDelay:E.clampedInt(t.hidingDelay,this.defaultValue.hidingDelay,0,6e5),above:_(t.above,this.defaultValue.above)}}}),inDiffEditor:B(new v(61,"inDiffEditor",!1)),letterSpacing:B(new S(64,"letterSpacing",U.letterSpacing,(e=>S.clamp(e,-5,20)),{description:c.kg("letterSpacing","Controls the letter spacing in pixels.")})),lightbulb:B(new class extends u{constructor(){const e={enabled:x.OnCode};super(65,"lightbulb",e,{"editor.lightbulb.enabled":{type:"string",tags:["experimental"],enum:[x.Off,x.OnCode,x.On],default:e.enabled,enumDescriptions:[c.kg("editor.lightbulb.enabled.off","Disable the code action menu."),c.kg("editor.lightbulb.enabled.onCode","Show the code action menu when the cursor is on lines with code."),c.kg("editor.lightbulb.enabled.on","Show the code action menu when the cursor is on lines with code or on empty lines.")],description:c.kg("enabled","Enables the Code Action lightbulb in the editor.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;return{enabled:w(e.enabled,this.defaultValue.enabled,[x.Off,x.OnCode,x.On])}}}),lineDecorationsWidth:B(new class extends u{constructor(){super(66,"lineDecorationsWidth",10)}validate(e){if("string"===typeof e&&/^\d+(\.\d+)?ch$/.test(e)){return-parseFloat(e.substring(0,e.length-2))}return E.clampedInt(e,this.defaultValue,0,1e3)}compute(e,t,i){return i<0?E.clampedInt(-i*e.fontInfo.typicalHalfwidthCharacterWidth,this.defaultValue,0,1e3):i}}),lineHeight:B(new class extends S{constructor(){super(67,"lineHeight",U.lineHeight,(e=>S.clamp(e,0,150)),{markdownDescription:c.kg("lineHeight","Controls the line height. \n - Use 0 to automatically compute the line height from the font size.\n - Values between 0 and 8 will be used as a multiplier with the font size.\n - Values greater than or equal to 8 will be used as effective values.")})}compute(e,t,i){return e.fontInfo.lineHeight}}),lineNumbers:B(new class extends u{constructor(){super(68,"lineNumbers",{renderType:1,renderFn:null},{type:"string",enum:["off","on","relative","interval"],enumDescriptions:[c.kg("lineNumbers.off","Line numbers are not rendered."),c.kg("lineNumbers.on","Line numbers are rendered as absolute number."),c.kg("lineNumbers.relative","Line numbers are rendered as distance in lines to cursor position."),c.kg("lineNumbers.interval","Line numbers are rendered every 10 lines.")],default:"on",description:c.kg("lineNumbers","Controls the display of line numbers.")})}validate(e){let t=this.defaultValue.renderType,i=this.defaultValue.renderFn;return"undefined"!==typeof e&&("function"===typeof e?(t=4,i=e):t="interval"===e?3:"relative"===e?2:"on"===e?1:0),{renderType:t,renderFn:i}}}),lineNumbersMinChars:B(new E(69,"lineNumbersMinChars",5,1,300)),linkedEditing:B(new v(70,"linkedEditing",!1,{description:c.kg("linkedEditing","Controls whether the editor has linked editing enabled. Depending on the language, related symbols such as HTML tags, are updated while editing.")})),links:B(new v(71,"links",!0,{description:c.kg("links","Controls whether the editor should detect links and make them clickable.")})),matchBrackets:B(new R(72,"matchBrackets","always",["always","near","never"],{description:c.kg("matchBrackets","Highlight matching brackets.")})),minimap:B(new class extends u{constructor(){const e={enabled:!0,size:"proportional",side:"right",showSlider:"mouseover",autohide:!1,renderCharacters:!0,maxColumn:120,scale:1,showRegionSectionHeaders:!0,showMarkSectionHeaders:!0,sectionHeaderFontSize:9,sectionHeaderLetterSpacing:1};super(73,"minimap",e,{"editor.minimap.enabled":{type:"boolean",default:e.enabled,description:c.kg("minimap.enabled","Controls whether the minimap is shown.")},"editor.minimap.autohide":{type:"boolean",default:e.autohide,description:c.kg("minimap.autohide","Controls whether the minimap is hidden automatically.")},"editor.minimap.size":{type:"string",enum:["proportional","fill","fit"],enumDescriptions:[c.kg("minimap.size.proportional","The minimap has the same size as the editor contents (and might scroll)."),c.kg("minimap.size.fill","The minimap will stretch or shrink as necessary to fill the height of the editor (no scrolling)."),c.kg("minimap.size.fit","The minimap will shrink as necessary to never be larger than the editor (no scrolling).")],default:e.size,description:c.kg("minimap.size","Controls the size of the minimap.")},"editor.minimap.side":{type:"string",enum:["left","right"],default:e.side,description:c.kg("minimap.side","Controls the side where to render the minimap.")},"editor.minimap.showSlider":{type:"string",enum:["always","mouseover"],default:e.showSlider,description:c.kg("minimap.showSlider","Controls when the minimap slider is shown.")},"editor.minimap.scale":{type:"number",default:e.scale,minimum:1,maximum:3,enum:[1,2,3],description:c.kg("minimap.scale","Scale of content drawn in the minimap: 1, 2 or 3.")},"editor.minimap.renderCharacters":{type:"boolean",default:e.renderCharacters,description:c.kg("minimap.renderCharacters","Render the actual characters on a line as opposed to color blocks.")},"editor.minimap.maxColumn":{type:"number",default:e.maxColumn,description:c.kg("minimap.maxColumn","Limit the width of the minimap to render at most a certain number of columns.")},"editor.minimap.showRegionSectionHeaders":{type:"boolean",default:e.showRegionSectionHeaders,description:c.kg("minimap.showRegionSectionHeaders","Controls whether named regions are shown as section headers in the minimap.")},"editor.minimap.showMarkSectionHeaders":{type:"boolean",default:e.showMarkSectionHeaders,description:c.kg("minimap.showMarkSectionHeaders","Controls whether MARK: comments are shown as section headers in the minimap.")},"editor.minimap.sectionHeaderFontSize":{type:"number",default:e.sectionHeaderFontSize,description:c.kg("minimap.sectionHeaderFontSize","Controls the font size of section headers in the minimap.")},"editor.minimap.sectionHeaderLetterSpacing":{type:"number",default:e.sectionHeaderLetterSpacing,description:c.kg("minimap.sectionHeaderLetterSpacing","Controls the amount of space (in pixels) between characters of section header. This helps the readability of the header in small font sizes.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),autohide:_(t.autohide,this.defaultValue.autohide),size:w(t.size,this.defaultValue.size,["proportional","fill","fit"]),side:w(t.side,this.defaultValue.side,["right","left"]),showSlider:w(t.showSlider,this.defaultValue.showSlider,["always","mouseover"]),renderCharacters:_(t.renderCharacters,this.defaultValue.renderCharacters),scale:E.clampedInt(t.scale,1,1,3),maxColumn:E.clampedInt(t.maxColumn,this.defaultValue.maxColumn,1,1e4),showRegionSectionHeaders:_(t.showRegionSectionHeaders,this.defaultValue.showRegionSectionHeaders),showMarkSectionHeaders:_(t.showMarkSectionHeaders,this.defaultValue.showMarkSectionHeaders),sectionHeaderFontSize:S.clamp(t.sectionHeaderFontSize??this.defaultValue.sectionHeaderFontSize,4,32),sectionHeaderLetterSpacing:S.clamp(t.sectionHeaderLetterSpacing??this.defaultValue.sectionHeaderLetterSpacing,0,5)}}}),mouseStyle:B(new R(74,"mouseStyle","text",["text","default","copy"])),mouseWheelScrollSensitivity:B(new S(75,"mouseWheelScrollSensitivity",1,(e=>0===e?1:e),{markdownDescription:c.kg("mouseWheelScrollSensitivity","A multiplier to be used on the `deltaX` and `deltaY` of mouse wheel scroll events.")})),mouseWheelZoom:B(new v(76,"mouseWheelZoom",!1,{markdownDescription:r.zx?c.kg("mouseWheelZoom.mac","Zoom the font of the editor when using mouse wheel and holding `Cmd`."):c.kg("mouseWheelZoom","Zoom the font of the editor when using mouse wheel and holding `Ctrl`.")})),multiCursorMergeOverlapping:B(new v(77,"multiCursorMergeOverlapping",!0,{description:c.kg("multiCursorMergeOverlapping","Merge multiple cursors when they are overlapping.")})),multiCursorModifier:B(new L(78,"multiCursorModifier","altKey","alt",["ctrlCmd","alt"],(function(e){return"ctrlCmd"===e?r.zx?"metaKey":"ctrlKey":"altKey"}),{markdownEnumDescriptions:[c.kg("multiCursorModifier.ctrlCmd","Maps to `Control` on Windows and Linux and to `Command` on macOS."),c.kg("multiCursorModifier.alt","Maps to `Alt` on Windows and Linux and to `Option` on macOS.")],markdownDescription:c.kg({key:"multiCursorModifier",comment:["- `ctrlCmd` refers to a value the setting can take and should not be localized.","- `Control` and `Command` refer to the modifier keys Ctrl or Cmd on the keyboard and can be localized."]},"The modifier to be used to add multiple cursors with the mouse. The Go to Definition and Open Link mouse gestures will adapt such that they do not conflict with the [multicursor modifier](https://code.visualstudio.com/docs/editor/codebasics#_multicursor-modifier).")})),multiCursorPaste:B(new R(79,"multiCursorPaste","spread",["spread","full"],{markdownEnumDescriptions:[c.kg("multiCursorPaste.spread","Each cursor pastes a single line of the text."),c.kg("multiCursorPaste.full","Each cursor pastes the full text.")],markdownDescription:c.kg("multiCursorPaste","Controls pasting when the line count of the pasted text matches the cursor count.")})),multiCursorLimit:B(new E(80,"multiCursorLimit",1e4,1,1e5,{markdownDescription:c.kg("multiCursorLimit","Controls the max number of cursors that can be in an active editor at once.")})),occurrencesHighlight:B(new R(81,"occurrencesHighlight","singleFile",["off","singleFile","multiFile"],{markdownEnumDescriptions:[c.kg("occurrencesHighlight.off","Does not highlight occurrences."),c.kg("occurrencesHighlight.singleFile","Highlights occurrences only in the current file."),c.kg("occurrencesHighlight.multiFile","Experimental: Highlights occurrences across all valid open files.")],markdownDescription:c.kg("occurrencesHighlight","Controls whether occurrences should be highlighted across open files.")})),overviewRulerBorder:B(new v(82,"overviewRulerBorder",!0,{description:c.kg("overviewRulerBorder","Controls whether a border should be drawn around the overview ruler.")})),overviewRulerLanes:B(new E(83,"overviewRulerLanes",3,0,3)),padding:B(new class extends u{constructor(){super(84,"padding",{top:0,bottom:0},{"editor.padding.top":{type:"number",default:0,minimum:0,maximum:1e3,description:c.kg("padding.top","Controls the amount of space between the top edge of the editor and the first line.")},"editor.padding.bottom":{type:"number",default:0,minimum:0,maximum:1e3,description:c.kg("padding.bottom","Controls the amount of space between the bottom edge of the editor and the last line.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{top:E.clampedInt(t.top,0,0,1e3),bottom:E.clampedInt(t.bottom,0,0,1e3)}}}),pasteAs:B(new class extends u{constructor(){const e={enabled:!0,showPasteSelector:"afterPaste"};super(85,"pasteAs",e,{"editor.pasteAs.enabled":{type:"boolean",default:e.enabled,markdownDescription:c.kg("pasteAs.enabled","Controls whether you can paste content in different ways.")},"editor.pasteAs.showPasteSelector":{type:"string",markdownDescription:c.kg("pasteAs.showPasteSelector","Controls if a widget is shown when pasting content in to the editor. This widget lets you control how the file is pasted."),enum:["afterPaste","never"],enumDescriptions:[c.kg("pasteAs.showPasteSelector.afterPaste","Show the paste selector widget after content is pasted into the editor."),c.kg("pasteAs.showPasteSelector.never","Never show the paste selector widget. Instead the default pasting behavior is always used.")],default:"afterPaste"}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),showPasteSelector:w(t.showPasteSelector,this.defaultValue.showPasteSelector,["afterPaste","never"])}}}),parameterHints:B(new class extends u{constructor(){const e={enabled:!0,cycle:!0};super(86,"parameterHints",e,{"editor.parameterHints.enabled":{type:"boolean",default:e.enabled,description:c.kg("parameterHints.enabled","Enables a pop-up that shows parameter documentation and type information as you type.")},"editor.parameterHints.cycle":{type:"boolean",default:e.cycle,description:c.kg("parameterHints.cycle","Controls whether the parameter hints menu cycles or closes when reaching the end of the list.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),cycle:_(t.cycle,this.defaultValue.cycle)}}}),peekWidgetDefaultFocus:B(new R(87,"peekWidgetDefaultFocus","tree",["tree","editor"],{enumDescriptions:[c.kg("peekWidgetDefaultFocus.tree","Focus the tree when opening peek"),c.kg("peekWidgetDefaultFocus.editor","Focus the editor when opening peek")],description:c.kg("peekWidgetDefaultFocus","Controls whether to focus the inline editor or the tree in the peek widget.")})),placeholder:B(new class extends u{constructor(){super(88,"placeholder",void 0)}validate(e){return"undefined"===typeof e?this.defaultValue:"string"===typeof e?e:this.defaultValue}}),definitionLinkOpensInPeek:B(new v(89,"definitionLinkOpensInPeek",!1,{description:c.kg("definitionLinkOpensInPeek","Controls whether the Go to Definition mouse gesture always opens the peek widget.")})),quickSuggestions:B(new class extends u{constructor(){const e={other:"on",comments:"off",strings:"off"},t=[{type:"boolean"},{type:"string",enum:["on","inline","off"],enumDescriptions:[c.kg("on","Quick suggestions show inside the suggest widget"),c.kg("inline","Quick suggestions show as ghost text"),c.kg("off","Quick suggestions are disabled")]}];super(90,"quickSuggestions",e,{type:"object",additionalProperties:!1,properties:{strings:{anyOf:t,default:e.strings,description:c.kg("quickSuggestions.strings","Enable quick suggestions inside strings.")},comments:{anyOf:t,default:e.comments,description:c.kg("quickSuggestions.comments","Enable quick suggestions inside comments.")},other:{anyOf:t,default:e.other,description:c.kg("quickSuggestions.other","Enable quick suggestions outside of strings and comments.")}},default:e,markdownDescription:c.kg("quickSuggestions","Controls whether suggestions should automatically show up while typing. This can be controlled for typing in comments, strings, and other code. Quick suggestion can be configured to show as ghost text or with the suggest widget. Also be aware of the {0}-setting which controls if suggestions are triggered by special characters.","`#editor.suggestOnTriggerCharacters#`")}),this.defaultValue=e}validate(e){if("boolean"===typeof e){const t=e?"on":"off";return{comments:t,strings:t,other:t}}if(!e||"object"!==typeof e)return this.defaultValue;const{other:t,comments:i,strings:s}=e,n=["on","inline","off"];let r,o,a;return r="boolean"===typeof t?t?"on":"off":w(t,this.defaultValue.other,n),o="boolean"===typeof i?i?"on":"off":w(i,this.defaultValue.comments,n),a="boolean"===typeof s?s?"on":"off":w(s,this.defaultValue.strings,n),{other:r,comments:o,strings:a}}}),quickSuggestionsDelay:B(new E(91,"quickSuggestionsDelay",10,0,1073741824,{description:c.kg("quickSuggestionsDelay","Controls the delay in milliseconds after which quick suggestions will show up.")})),readOnly:B(new v(92,"readOnly",!1)),readOnlyMessage:B(new class extends u{constructor(){super(93,"readOnlyMessage",undefined)}validate(e){return e&&"object"===typeof e?e:this.defaultValue}}),renameOnType:B(new v(94,"renameOnType",!1,{description:c.kg("renameOnType","Controls whether the editor auto renames on type."),markdownDeprecationMessage:c.kg("renameOnTypeDeprecate","Deprecated, use `editor.linkedEditing` instead.")})),renderControlCharacters:B(new v(95,"renderControlCharacters",!0,{description:c.kg("renderControlCharacters","Controls whether the editor should render control characters."),restricted:!0})),renderFinalNewline:B(new R(96,"renderFinalNewline",r.j9?"dimmed":"on",["off","on","dimmed"],{description:c.kg("renderFinalNewline","Render last line number when the file ends with a newline.")})),renderLineHighlight:B(new R(97,"renderLineHighlight","line",["none","gutter","line","all"],{enumDescriptions:["","","",c.kg("renderLineHighlight.all","Highlights both the gutter and the current line.")],description:c.kg("renderLineHighlight","Controls how the editor should render the current line highlight.")})),renderLineHighlightOnlyWhenFocus:B(new v(98,"renderLineHighlightOnlyWhenFocus",!1,{description:c.kg("renderLineHighlightOnlyWhenFocus","Controls if the editor should render the current line highlight only when the editor is focused.")})),renderValidationDecorations:B(new R(99,"renderValidationDecorations","editable",["editable","on","off"])),renderWhitespace:B(new R(100,"renderWhitespace","selection",["none","boundary","selection","trailing","all"],{enumDescriptions:["",c.kg("renderWhitespace.boundary","Render whitespace characters except for single spaces between words."),c.kg("renderWhitespace.selection","Render whitespace characters only on selected text."),c.kg("renderWhitespace.trailing","Render only trailing whitespace characters."),""],description:c.kg("renderWhitespace","Controls how the editor should render whitespace characters.")})),revealHorizontalRightPadding:B(new E(101,"revealHorizontalRightPadding",15,0,1e3)),roundedSelection:B(new v(102,"roundedSelection",!0,{description:c.kg("roundedSelection","Controls whether selections should have rounded corners.")})),rulers:B(new class extends u{constructor(){const e=[],t={type:"number",description:c.kg("rulers.size","Number of monospace characters at which this editor ruler will render.")};super(103,"rulers",e,{type:"array",items:{anyOf:[t,{type:["object"],properties:{column:t,color:{type:"string",description:c.kg("rulers.color","Color of this editor ruler."),format:"color-hex"}}}]},default:e,description:c.kg("rulers","Render vertical rulers after a certain number of monospace characters. Use multiple values for multiple rulers. No rulers are drawn if array is empty.")})}validate(e){if(Array.isArray(e)){const t=[];for(const i of e)if("number"===typeof i)t.push({column:E.clampedInt(i,0,0,1e4),color:null});else if(i&&"object"===typeof i){const e=i;t.push({column:E.clampedInt(e.column,0,0,1e4),color:e.color})}return t.sort(((e,t)=>e.column-t.column)),t}return this.defaultValue}}),scrollbar:B(new class extends u{constructor(){const e={vertical:1,horizontal:1,arrowSize:11,useShadows:!0,verticalHasArrows:!1,horizontalHasArrows:!1,horizontalScrollbarSize:12,horizontalSliderSize:12,verticalScrollbarSize:14,verticalSliderSize:14,handleMouseWheel:!0,alwaysConsumeMouseWheel:!0,scrollByPage:!1,ignoreHorizontalScrollbarInContentHeight:!1};super(104,"scrollbar",e,{"editor.scrollbar.vertical":{type:"string",enum:["auto","visible","hidden"],enumDescriptions:[c.kg("scrollbar.vertical.auto","The vertical scrollbar will be visible only when necessary."),c.kg("scrollbar.vertical.visible","The vertical scrollbar will always be visible."),c.kg("scrollbar.vertical.fit","The vertical scrollbar will always be hidden.")],default:"auto",description:c.kg("scrollbar.vertical","Controls the visibility of the vertical scrollbar.")},"editor.scrollbar.horizontal":{type:"string",enum:["auto","visible","hidden"],enumDescriptions:[c.kg("scrollbar.horizontal.auto","The horizontal scrollbar will be visible only when necessary."),c.kg("scrollbar.horizontal.visible","The horizontal scrollbar will always be visible."),c.kg("scrollbar.horizontal.fit","The horizontal scrollbar will always be hidden.")],default:"auto",description:c.kg("scrollbar.horizontal","Controls the visibility of the horizontal scrollbar.")},"editor.scrollbar.verticalScrollbarSize":{type:"number",default:e.verticalScrollbarSize,description:c.kg("scrollbar.verticalScrollbarSize","The width of the vertical scrollbar.")},"editor.scrollbar.horizontalScrollbarSize":{type:"number",default:e.horizontalScrollbarSize,description:c.kg("scrollbar.horizontalScrollbarSize","The height of the horizontal scrollbar.")},"editor.scrollbar.scrollByPage":{type:"boolean",default:e.scrollByPage,description:c.kg("scrollbar.scrollByPage","Controls whether clicks scroll by page or jump to click position.")},"editor.scrollbar.ignoreHorizontalScrollbarInContentHeight":{type:"boolean",default:e.ignoreHorizontalScrollbarInContentHeight,description:c.kg("scrollbar.ignoreHorizontalScrollbarInContentHeight","When set, the horizontal scrollbar will not increase the size of the editor's content.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e,i=E.clampedInt(t.horizontalScrollbarSize,this.defaultValue.horizontalScrollbarSize,0,1e3),s=E.clampedInt(t.verticalScrollbarSize,this.defaultValue.verticalScrollbarSize,0,1e3);return{arrowSize:E.clampedInt(t.arrowSize,this.defaultValue.arrowSize,0,1e3),vertical:D(t.vertical,this.defaultValue.vertical),horizontal:D(t.horizontal,this.defaultValue.horizontal),useShadows:_(t.useShadows,this.defaultValue.useShadows),verticalHasArrows:_(t.verticalHasArrows,this.defaultValue.verticalHasArrows),horizontalHasArrows:_(t.horizontalHasArrows,this.defaultValue.horizontalHasArrows),handleMouseWheel:_(t.handleMouseWheel,this.defaultValue.handleMouseWheel),alwaysConsumeMouseWheel:_(t.alwaysConsumeMouseWheel,this.defaultValue.alwaysConsumeMouseWheel),horizontalScrollbarSize:i,horizontalSliderSize:E.clampedInt(t.horizontalSliderSize,i,0,1e3),verticalScrollbarSize:s,verticalSliderSize:E.clampedInt(t.verticalSliderSize,s,0,1e3),scrollByPage:_(t.scrollByPage,this.defaultValue.scrollByPage),ignoreHorizontalScrollbarInContentHeight:_(t.ignoreHorizontalScrollbarInContentHeight,this.defaultValue.ignoreHorizontalScrollbarInContentHeight)}}}),scrollBeyondLastColumn:B(new E(105,"scrollBeyondLastColumn",4,0,1073741824,{description:c.kg("scrollBeyondLastColumn","Controls the number of extra characters beyond which the editor will scroll horizontally.")})),scrollBeyondLastLine:B(new v(106,"scrollBeyondLastLine",!0,{description:c.kg("scrollBeyondLastLine","Controls whether the editor will scroll beyond the last line.")})),scrollPredominantAxis:B(new v(107,"scrollPredominantAxis",!0,{description:c.kg("scrollPredominantAxis","Scroll only along the predominant axis when scrolling both vertically and horizontally at the same time. Prevents horizontal drift when scrolling vertically on a trackpad.")})),selectionClipboard:B(new v(108,"selectionClipboard",!0,{description:c.kg("selectionClipboard","Controls whether the Linux primary clipboard should be supported."),included:r.j9})),selectionHighlight:B(new v(109,"selectionHighlight",!0,{description:c.kg("selectionHighlight","Controls whether the editor should highlight matches similar to the selection.")})),selectOnLineNumbers:B(new v(110,"selectOnLineNumbers",!0)),showFoldingControls:B(new R(111,"showFoldingControls","mouseover",["always","never","mouseover"],{enumDescriptions:[c.kg("showFoldingControls.always","Always show the folding controls."),c.kg("showFoldingControls.never","Never show the folding controls and reduce the gutter size."),c.kg("showFoldingControls.mouseover","Only show the folding controls when the mouse is over the gutter.")],description:c.kg("showFoldingControls","Controls when the folding controls on the gutter are shown.")})),showUnused:B(new v(112,"showUnused",!0,{description:c.kg("showUnused","Controls fading out of unused code.")})),showDeprecated:B(new v(141,"showDeprecated",!0,{description:c.kg("showDeprecated","Controls strikethrough deprecated variables.")})),inlayHints:B(new class extends u{constructor(){const e={enabled:"on",fontSize:0,fontFamily:"",padding:!1};super(142,"inlayHints",e,{"editor.inlayHints.enabled":{type:"string",default:e.enabled,description:c.kg("inlayHints.enable","Enables the inlay hints in the editor."),enum:["on","onUnlessPressed","offUnlessPressed","off"],markdownEnumDescriptions:[c.kg("editor.inlayHints.on","Inlay hints are enabled"),c.kg("editor.inlayHints.onUnlessPressed","Inlay hints are showing by default and hide when holding {0}",r.zx?"Ctrl+Option":"Ctrl+Alt"),c.kg("editor.inlayHints.offUnlessPressed","Inlay hints are hidden by default and show when holding {0}",r.zx?"Ctrl+Option":"Ctrl+Alt"),c.kg("editor.inlayHints.off","Inlay hints are disabled")]},"editor.inlayHints.fontSize":{type:"number",default:e.fontSize,markdownDescription:c.kg("inlayHints.fontSize","Controls font size of inlay hints in the editor. As default the {0} is used when the configured value is less than {1} or greater than the editor font size.","`#editor.fontSize#`","`5`")},"editor.inlayHints.fontFamily":{type:"string",default:e.fontFamily,markdownDescription:c.kg("inlayHints.fontFamily","Controls font family of inlay hints in the editor. When set to empty, the {0} is used.","`#editor.fontFamily#`")},"editor.inlayHints.padding":{type:"boolean",default:e.padding,description:c.kg("inlayHints.padding","Enables the padding around the inlay hints in the editor.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return"boolean"===typeof t.enabled&&(t.enabled=t.enabled?"on":"off"),{enabled:w(t.enabled,this.defaultValue.enabled,["on","off","offUnlessPressed","onUnlessPressed"]),fontSize:E.clampedInt(t.fontSize,this.defaultValue.fontSize,0,100),fontFamily:y.string(t.fontFamily,this.defaultValue.fontFamily),padding:_(t.padding,this.defaultValue.padding)}}}),snippetSuggestions:B(new R(113,"snippetSuggestions","inline",["top","bottom","inline","none"],{enumDescriptions:[c.kg("snippetSuggestions.top","Show snippet suggestions on top of other suggestions."),c.kg("snippetSuggestions.bottom","Show snippet suggestions below other suggestions."),c.kg("snippetSuggestions.inline","Show snippets suggestions with other suggestions."),c.kg("snippetSuggestions.none","Do not show snippet suggestions.")],description:c.kg("snippetSuggestions","Controls whether snippets are shown with other suggestions and how they are sorted.")})),smartSelect:B(new class extends u{constructor(){super(114,"smartSelect",{selectLeadingAndTrailingWhitespace:!0,selectSubwords:!0},{"editor.smartSelect.selectLeadingAndTrailingWhitespace":{description:c.kg("selectLeadingAndTrailingWhitespace","Whether leading and trailing whitespace should always be selected."),default:!0,type:"boolean"},"editor.smartSelect.selectSubwords":{description:c.kg("selectSubwords","Whether subwords (like 'foo' in 'fooBar' or 'foo_bar') should be selected."),default:!0,type:"boolean"}})}validate(e){return e&&"object"===typeof e?{selectLeadingAndTrailingWhitespace:_(e.selectLeadingAndTrailingWhitespace,this.defaultValue.selectLeadingAndTrailingWhitespace),selectSubwords:_(e.selectSubwords,this.defaultValue.selectSubwords)}:this.defaultValue}}),smoothScrolling:B(new v(115,"smoothScrolling",!1,{description:c.kg("smoothScrolling","Controls whether the editor will scroll using an animation.")})),stopRenderingLineAfter:B(new E(118,"stopRenderingLineAfter",1e4,-1,1073741824)),suggest:B(new class extends u{constructor(){const e={insertMode:"insert",filterGraceful:!0,snippetsPreventQuickSuggestions:!1,localityBonus:!1,shareSuggestSelections:!1,selectionMode:"always",showIcons:!0,showStatusBar:!1,preview:!1,previewMode:"subwordSmart",showInlineDetails:!0,showMethods:!0,showFunctions:!0,showConstructors:!0,showDeprecated:!0,matchOnWordStartOnly:!0,showFields:!0,showVariables:!0,showClasses:!0,showStructs:!0,showInterfaces:!0,showModules:!0,showProperties:!0,showEvents:!0,showOperators:!0,showUnits:!0,showValues:!0,showConstants:!0,showEnums:!0,showEnumMembers:!0,showKeywords:!0,showWords:!0,showColors:!0,showFiles:!0,showReferences:!0,showFolders:!0,showTypeParameters:!0,showSnippets:!0,showUsers:!0,showIssues:!0};super(119,"suggest",e,{"editor.suggest.insertMode":{type:"string",enum:["insert","replace"],enumDescriptions:[c.kg("suggest.insertMode.insert","Insert suggestion without overwriting text right of the cursor."),c.kg("suggest.insertMode.replace","Insert suggestion and overwrite text right of the cursor.")],default:e.insertMode,description:c.kg("suggest.insertMode","Controls whether words are overwritten when accepting completions. Note that this depends on extensions opting into this feature.")},"editor.suggest.filterGraceful":{type:"boolean",default:e.filterGraceful,description:c.kg("suggest.filterGraceful","Controls whether filtering and sorting suggestions accounts for small typos.")},"editor.suggest.localityBonus":{type:"boolean",default:e.localityBonus,description:c.kg("suggest.localityBonus","Controls whether sorting favors words that appear close to the cursor.")},"editor.suggest.shareSuggestSelections":{type:"boolean",default:e.shareSuggestSelections,markdownDescription:c.kg("suggest.shareSuggestSelections","Controls whether remembered suggestion selections are shared between multiple workspaces and windows (needs `#editor.suggestSelection#`).")},"editor.suggest.selectionMode":{type:"string",enum:["always","never","whenTriggerCharacter","whenQuickSuggestion"],enumDescriptions:[c.kg("suggest.insertMode.always","Always select a suggestion when automatically triggering IntelliSense."),c.kg("suggest.insertMode.never","Never select a suggestion when automatically triggering IntelliSense."),c.kg("suggest.insertMode.whenTriggerCharacter","Select a suggestion only when triggering IntelliSense from a trigger character."),c.kg("suggest.insertMode.whenQuickSuggestion","Select a suggestion only when triggering IntelliSense as you type.")],default:e.selectionMode,markdownDescription:c.kg("suggest.selectionMode","Controls whether a suggestion is selected when the widget shows. Note that this only applies to automatically triggered suggestions ({0} and {1}) and that a suggestion is always selected when explicitly invoked, e.g via `Ctrl+Space`.","`#editor.quickSuggestions#`","`#editor.suggestOnTriggerCharacters#`")},"editor.suggest.snippetsPreventQuickSuggestions":{type:"boolean",default:e.snippetsPreventQuickSuggestions,description:c.kg("suggest.snippetsPreventQuickSuggestions","Controls whether an active snippet prevents quick suggestions.")},"editor.suggest.showIcons":{type:"boolean",default:e.showIcons,description:c.kg("suggest.showIcons","Controls whether to show or hide icons in suggestions.")},"editor.suggest.showStatusBar":{type:"boolean",default:e.showStatusBar,description:c.kg("suggest.showStatusBar","Controls the visibility of the status bar at the bottom of the suggest widget.")},"editor.suggest.preview":{type:"boolean",default:e.preview,description:c.kg("suggest.preview","Controls whether to preview the suggestion outcome in the editor.")},"editor.suggest.showInlineDetails":{type:"boolean",default:e.showInlineDetails,description:c.kg("suggest.showInlineDetails","Controls whether suggest details show inline with the label or only in the details widget.")},"editor.suggest.maxVisibleSuggestions":{type:"number",deprecationMessage:c.kg("suggest.maxVisibleSuggestions.dep","This setting is deprecated. The suggest widget can now be resized.")},"editor.suggest.filteredTypes":{type:"object",deprecationMessage:c.kg("deprecated","This setting is deprecated, please use separate settings like 'editor.suggest.showKeywords' or 'editor.suggest.showSnippets' instead.")},"editor.suggest.showMethods":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showMethods","When enabled IntelliSense shows `method`-suggestions.")},"editor.suggest.showFunctions":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showFunctions","When enabled IntelliSense shows `function`-suggestions.")},"editor.suggest.showConstructors":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showConstructors","When enabled IntelliSense shows `constructor`-suggestions.")},"editor.suggest.showDeprecated":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showDeprecated","When enabled IntelliSense shows `deprecated`-suggestions.")},"editor.suggest.matchOnWordStartOnly":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.matchOnWordStartOnly","When enabled IntelliSense filtering requires that the first character matches on a word start. For example, `c` on `Console` or `WebContext` but _not_ on `description`. When disabled IntelliSense will show more results but still sorts them by match quality.")},"editor.suggest.showFields":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showFields","When enabled IntelliSense shows `field`-suggestions.")},"editor.suggest.showVariables":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showVariables","When enabled IntelliSense shows `variable`-suggestions.")},"editor.suggest.showClasses":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showClasss","When enabled IntelliSense shows `class`-suggestions.")},"editor.suggest.showStructs":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showStructs","When enabled IntelliSense shows `struct`-suggestions.")},"editor.suggest.showInterfaces":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showInterfaces","When enabled IntelliSense shows `interface`-suggestions.")},"editor.suggest.showModules":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showModules","When enabled IntelliSense shows `module`-suggestions.")},"editor.suggest.showProperties":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showPropertys","When enabled IntelliSense shows `property`-suggestions.")},"editor.suggest.showEvents":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showEvents","When enabled IntelliSense shows `event`-suggestions.")},"editor.suggest.showOperators":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showOperators","When enabled IntelliSense shows `operator`-suggestions.")},"editor.suggest.showUnits":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showUnits","When enabled IntelliSense shows `unit`-suggestions.")},"editor.suggest.showValues":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showValues","When enabled IntelliSense shows `value`-suggestions.")},"editor.suggest.showConstants":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showConstants","When enabled IntelliSense shows `constant`-suggestions.")},"editor.suggest.showEnums":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showEnums","When enabled IntelliSense shows `enum`-suggestions.")},"editor.suggest.showEnumMembers":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showEnumMembers","When enabled IntelliSense shows `enumMember`-suggestions.")},"editor.suggest.showKeywords":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showKeywords","When enabled IntelliSense shows `keyword`-suggestions.")},"editor.suggest.showWords":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showTexts","When enabled IntelliSense shows `text`-suggestions.")},"editor.suggest.showColors":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showColors","When enabled IntelliSense shows `color`-suggestions.")},"editor.suggest.showFiles":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showFiles","When enabled IntelliSense shows `file`-suggestions.")},"editor.suggest.showReferences":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showReferences","When enabled IntelliSense shows `reference`-suggestions.")},"editor.suggest.showCustomcolors":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showCustomcolors","When enabled IntelliSense shows `customcolor`-suggestions.")},"editor.suggest.showFolders":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showFolders","When enabled IntelliSense shows `folder`-suggestions.")},"editor.suggest.showTypeParameters":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showTypeParameters","When enabled IntelliSense shows `typeParameter`-suggestions.")},"editor.suggest.showSnippets":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showSnippets","When enabled IntelliSense shows `snippet`-suggestions.")},"editor.suggest.showUsers":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showUsers","When enabled IntelliSense shows `user`-suggestions.")},"editor.suggest.showIssues":{type:"boolean",default:!0,markdownDescription:c.kg("editor.suggest.showIssues","When enabled IntelliSense shows `issues`-suggestions.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{insertMode:w(t.insertMode,this.defaultValue.insertMode,["insert","replace"]),filterGraceful:_(t.filterGraceful,this.defaultValue.filterGraceful),snippetsPreventQuickSuggestions:_(t.snippetsPreventQuickSuggestions,this.defaultValue.filterGraceful),localityBonus:_(t.localityBonus,this.defaultValue.localityBonus),shareSuggestSelections:_(t.shareSuggestSelections,this.defaultValue.shareSuggestSelections),selectionMode:w(t.selectionMode,this.defaultValue.selectionMode,["always","never","whenQuickSuggestion","whenTriggerCharacter"]),showIcons:_(t.showIcons,this.defaultValue.showIcons),showStatusBar:_(t.showStatusBar,this.defaultValue.showStatusBar),preview:_(t.preview,this.defaultValue.preview),previewMode:w(t.previewMode,this.defaultValue.previewMode,["prefix","subword","subwordSmart"]),showInlineDetails:_(t.showInlineDetails,this.defaultValue.showInlineDetails),showMethods:_(t.showMethods,this.defaultValue.showMethods),showFunctions:_(t.showFunctions,this.defaultValue.showFunctions),showConstructors:_(t.showConstructors,this.defaultValue.showConstructors),showDeprecated:_(t.showDeprecated,this.defaultValue.showDeprecated),matchOnWordStartOnly:_(t.matchOnWordStartOnly,this.defaultValue.matchOnWordStartOnly),showFields:_(t.showFields,this.defaultValue.showFields),showVariables:_(t.showVariables,this.defaultValue.showVariables),showClasses:_(t.showClasses,this.defaultValue.showClasses),showStructs:_(t.showStructs,this.defaultValue.showStructs),showInterfaces:_(t.showInterfaces,this.defaultValue.showInterfaces),showModules:_(t.showModules,this.defaultValue.showModules),showProperties:_(t.showProperties,this.defaultValue.showProperties),showEvents:_(t.showEvents,this.defaultValue.showEvents),showOperators:_(t.showOperators,this.defaultValue.showOperators),showUnits:_(t.showUnits,this.defaultValue.showUnits),showValues:_(t.showValues,this.defaultValue.showValues),showConstants:_(t.showConstants,this.defaultValue.showConstants),showEnums:_(t.showEnums,this.defaultValue.showEnums),showEnumMembers:_(t.showEnumMembers,this.defaultValue.showEnumMembers),showKeywords:_(t.showKeywords,this.defaultValue.showKeywords),showWords:_(t.showWords,this.defaultValue.showWords),showColors:_(t.showColors,this.defaultValue.showColors),showFiles:_(t.showFiles,this.defaultValue.showFiles),showReferences:_(t.showReferences,this.defaultValue.showReferences),showFolders:_(t.showFolders,this.defaultValue.showFolders),showTypeParameters:_(t.showTypeParameters,this.defaultValue.showTypeParameters),showSnippets:_(t.showSnippets,this.defaultValue.showSnippets),showUsers:_(t.showUsers,this.defaultValue.showUsers),showIssues:_(t.showIssues,this.defaultValue.showIssues)}}}),inlineSuggest:B(new class extends u{constructor(){const e={enabled:!0,mode:"subwordSmart",showToolbar:"onHover",suppressSuggestions:!1,keepOnBlur:!1,fontFamily:"default"};super(62,"inlineSuggest",e,{"editor.inlineSuggest.enabled":{type:"boolean",default:e.enabled,description:c.kg("inlineSuggest.enabled","Controls whether to automatically show inline suggestions in the editor.")},"editor.inlineSuggest.showToolbar":{type:"string",default:e.showToolbar,enum:["always","onHover","never"],enumDescriptions:[c.kg("inlineSuggest.showToolbar.always","Show the inline suggestion toolbar whenever an inline suggestion is shown."),c.kg("inlineSuggest.showToolbar.onHover","Show the inline suggestion toolbar when hovering over an inline suggestion."),c.kg("inlineSuggest.showToolbar.never","Never show the inline suggestion toolbar.")],description:c.kg("inlineSuggest.showToolbar","Controls when to show the inline suggestion toolbar.")},"editor.inlineSuggest.suppressSuggestions":{type:"boolean",default:e.suppressSuggestions,description:c.kg("inlineSuggest.suppressSuggestions","Controls how inline suggestions interact with the suggest widget. If enabled, the suggest widget is not shown automatically when inline suggestions are available.")},"editor.inlineSuggest.fontFamily":{type:"string",default:e.fontFamily,description:c.kg("inlineSuggest.fontFamily","Controls the font family of the inline suggestions.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),mode:w(t.mode,this.defaultValue.mode,["prefix","subword","subwordSmart"]),showToolbar:w(t.showToolbar,this.defaultValue.showToolbar,["always","onHover","never"]),suppressSuggestions:_(t.suppressSuggestions,this.defaultValue.suppressSuggestions),keepOnBlur:_(t.keepOnBlur,this.defaultValue.keepOnBlur),fontFamily:y.string(t.fontFamily,this.defaultValue.fontFamily)}}}),inlineEdit:B(new class extends u{constructor(){const e={enabled:!1,showToolbar:"onHover",fontFamily:"default",keepOnBlur:!1};super(63,"experimentalInlineEdit",e,{"editor.experimentalInlineEdit.enabled":{type:"boolean",default:e.enabled,description:c.kg("inlineEdit.enabled","Controls whether to show inline edits in the editor.")},"editor.experimentalInlineEdit.showToolbar":{type:"string",default:e.showToolbar,enum:["always","onHover","never"],enumDescriptions:[c.kg("inlineEdit.showToolbar.always","Show the inline edit toolbar whenever an inline suggestion is shown."),c.kg("inlineEdit.showToolbar.onHover","Show the inline edit toolbar when hovering over an inline suggestion."),c.kg("inlineEdit.showToolbar.never","Never show the inline edit toolbar.")],description:c.kg("inlineEdit.showToolbar","Controls when to show the inline edit toolbar.")},"editor.experimentalInlineEdit.fontFamily":{type:"string",default:e.fontFamily,description:c.kg("inlineEdit.fontFamily","Controls the font family of the inline edit.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),showToolbar:w(t.showToolbar,this.defaultValue.showToolbar,["always","onHover","never"]),fontFamily:y.string(t.fontFamily,this.defaultValue.fontFamily),keepOnBlur:_(t.keepOnBlur,this.defaultValue.keepOnBlur)}}}),inlineCompletionsAccessibilityVerbose:B(new v(150,"inlineCompletionsAccessibilityVerbose",!1,{description:c.kg("inlineCompletionsAccessibilityVerbose","Controls whether the accessibility hint should be provided to screen reader users when an inline completion is shown.")})),suggestFontSize:B(new E(120,"suggestFontSize",0,0,1e3,{markdownDescription:c.kg("suggestFontSize","Font size for the suggest widget. When set to {0}, the value of {1} is used.","`0`","`#editor.fontSize#`")})),suggestLineHeight:B(new E(121,"suggestLineHeight",0,0,1e3,{markdownDescription:c.kg("suggestLineHeight","Line height for the suggest widget. When set to {0}, the value of {1} is used. The minimum value is 8.","`0`","`#editor.lineHeight#`")})),suggestOnTriggerCharacters:B(new v(122,"suggestOnTriggerCharacters",!0,{description:c.kg("suggestOnTriggerCharacters","Controls whether suggestions should automatically show up when typing trigger characters.")})),suggestSelection:B(new R(123,"suggestSelection","first",["first","recentlyUsed","recentlyUsedByPrefix"],{markdownEnumDescriptions:[c.kg("suggestSelection.first","Always select the first suggestion."),c.kg("suggestSelection.recentlyUsed","Select recent suggestions unless further typing selects one, e.g. `console.| -> console.log` because `log` has been completed recently."),c.kg("suggestSelection.recentlyUsedByPrefix","Select suggestions based on previous prefixes that have completed those suggestions, e.g. `co -> console` and `con -> const`.")],description:c.kg("suggestSelection","Controls how suggestions are pre-selected when showing the suggest list.")})),tabCompletion:B(new R(124,"tabCompletion","off",["on","off","onlySnippets"],{enumDescriptions:[c.kg("tabCompletion.on","Tab complete will insert the best matching suggestion when pressing tab."),c.kg("tabCompletion.off","Disable tab completions."),c.kg("tabCompletion.onlySnippets","Tab complete snippets when their prefix match. Works best when 'quickSuggestions' aren't enabled.")],description:c.kg("tabCompletion","Enables tab completions.")})),tabIndex:B(new E(125,"tabIndex",0,-1,1073741824)),unicodeHighlight:B(new class extends u{constructor(){const e={nonBasicASCII:M,invisibleCharacters:!0,ambiguousCharacters:!0,includeComments:M,includeStrings:!0,allowedCharacters:{},allowedLocales:{_os:!0,_vscode:!0}};super(126,"unicodeHighlight",e,{[P.nonBasicASCII]:{restricted:!0,type:["boolean","string"],enum:[!0,!1,M],default:e.nonBasicASCII,description:c.kg("unicodeHighlight.nonBasicASCII","Controls whether all non-basic ASCII characters are highlighted. Only characters between U+0020 and U+007E, tab, line-feed and carriage-return are considered basic ASCII.")},[P.invisibleCharacters]:{restricted:!0,type:"boolean",default:e.invisibleCharacters,description:c.kg("unicodeHighlight.invisibleCharacters","Controls whether characters that just reserve space or have no width at all are highlighted.")},[P.ambiguousCharacters]:{restricted:!0,type:"boolean",default:e.ambiguousCharacters,description:c.kg("unicodeHighlight.ambiguousCharacters","Controls whether characters are highlighted that can be confused with basic ASCII characters, except those that are common in the current user locale.")},[P.includeComments]:{restricted:!0,type:["boolean","string"],enum:[!0,!1,M],default:e.includeComments,description:c.kg("unicodeHighlight.includeComments","Controls whether characters in comments should also be subject to Unicode highlighting.")},[P.includeStrings]:{restricted:!0,type:["boolean","string"],enum:[!0,!1,M],default:e.includeStrings,description:c.kg("unicodeHighlight.includeStrings","Controls whether characters in strings should also be subject to Unicode highlighting.")},[P.allowedCharacters]:{restricted:!0,type:"object",default:e.allowedCharacters,description:c.kg("unicodeHighlight.allowedCharacters","Defines allowed characters that are not being highlighted."),additionalProperties:{type:"boolean"}},[P.allowedLocales]:{restricted:!0,type:"object",additionalProperties:{type:"boolean"},default:e.allowedLocales,description:c.kg("unicodeHighlight.allowedLocales","Unicode characters that are common in allowed locales are not being highlighted.")}})}applyUpdate(e,t){let i=!1;t.allowedCharacters&&e&&(n.aI(e.allowedCharacters,t.allowedCharacters)||(e={...e,allowedCharacters:t.allowedCharacters},i=!0)),t.allowedLocales&&e&&(n.aI(e.allowedLocales,t.allowedLocales)||(e={...e,allowedLocales:t.allowedLocales},i=!0));const s=super.applyUpdate(e,t);return i?new g(s.newValue,!0):s}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{nonBasicASCII:F(t.nonBasicASCII,M,[!0,!1,M]),invisibleCharacters:_(t.invisibleCharacters,this.defaultValue.invisibleCharacters),ambiguousCharacters:_(t.ambiguousCharacters,this.defaultValue.ambiguousCharacters),includeComments:F(t.includeComments,M,[!0,!1,M]),includeStrings:F(t.includeStrings,M,[!0,!1,M]),allowedCharacters:this.validateBooleanMap(e.allowedCharacters,this.defaultValue.allowedCharacters),allowedLocales:this.validateBooleanMap(e.allowedLocales,this.defaultValue.allowedLocales)}}validateBooleanMap(e,t){if("object"!==typeof e||!e)return t;const i={};for(const[s,n]of Object.entries(e))!0===n&&(i[s]=!0);return i}}),unusualLineTerminators:B(new R(127,"unusualLineTerminators","prompt",["auto","off","prompt"],{enumDescriptions:[c.kg("unusualLineTerminators.auto","Unusual line terminators are automatically removed."),c.kg("unusualLineTerminators.off","Unusual line terminators are ignored."),c.kg("unusualLineTerminators.prompt","Unusual line terminators prompt to be removed.")],description:c.kg("unusualLineTerminators","Remove unusual line terminators that might cause problems.")})),useShadowDOM:B(new v(128,"useShadowDOM",!0)),useTabStops:B(new v(129,"useTabStops",!0,{description:c.kg("useTabStops","Spaces and tabs are inserted and deleted in alignment with tab stops.")})),wordBreak:B(new R(130,"wordBreak","normal",["normal","keepAll"],{markdownEnumDescriptions:[c.kg("wordBreak.normal","Use the default line break rule."),c.kg("wordBreak.keepAll","Word breaks should not be used for Chinese/Japanese/Korean (CJK) text. Non-CJK text behavior is the same as for normal.")],description:c.kg("wordBreak","Controls the word break rules used for Chinese/Japanese/Korean (CJK) text.")})),wordSegmenterLocales:B(new class extends u{constructor(){super(131,"wordSegmenterLocales",[],{anyOf:[{description:c.kg("wordSegmenterLocales","Locales to be used for word segmentation when doing word related navigations or operations. Specify the BCP 47 language tag of the word you wish to recognize (e.g., ja, zh-CN, zh-Hant-TW, etc.)."),type:"string"},{description:c.kg("wordSegmenterLocales","Locales to be used for word segmentation when doing word related navigations or operations. Specify the BCP 47 language tag of the word you wish to recognize (e.g., ja, zh-CN, zh-Hant-TW, etc.)."),type:"array",items:{type:"string"}}]})}validate(e){if("string"===typeof e&&(e=[e]),Array.isArray(e)){const t=[];for(const i of e)if("string"===typeof i)try{Intl.Segmenter.supportedLocalesOf(i).length>0&&t.push(i)}catch{}return t}return this.defaultValue}}),wordSeparators:B(new y(132,"wordSeparators",a.J3,{description:c.kg("wordSeparators","Characters that will be used as word separators when doing word related navigations or operations.")})),wordWrap:B(new R(133,"wordWrap","off",["off","on","wordWrapColumn","bounded"],{markdownEnumDescriptions:[c.kg("wordWrap.off","Lines will never wrap."),c.kg("wordWrap.on","Lines will wrap at the viewport width."),c.kg({key:"wordWrap.wordWrapColumn",comment:["- `editor.wordWrapColumn` refers to a different setting and should not be localized."]},"Lines will wrap at `#editor.wordWrapColumn#`."),c.kg({key:"wordWrap.bounded",comment:["- viewport means the edge of the visible window size.","- `editor.wordWrapColumn` refers to a different setting and should not be localized."]},"Lines will wrap at the minimum of viewport and `#editor.wordWrapColumn#`.")],description:c.kg({key:"wordWrap",comment:["- 'off', 'on', 'wordWrapColumn' and 'bounded' refer to values the setting can take and should not be localized.","- `editor.wordWrapColumn` refers to a different setting and should not be localized."]},"Controls how lines should wrap.")})),wordWrapBreakAfterCharacters:B(new y(134,"wordWrapBreakAfterCharacters"," \t})]?|/&.,;\xa2\xb0\u2032\u2033\u2030\u2103\u3001\u3002\uff61\uff64\uffe0\uff0c\uff0e\uff1a\uff1b\uff1f\uff01\uff05\u30fb\uff65\u309d\u309e\u30fd\u30fe\u30fc\u30a1\u30a3\u30a5\u30a7\u30a9\u30c3\u30e3\u30e5\u30e7\u30ee\u30f5\u30f6\u3041\u3043\u3045\u3047\u3049\u3063\u3083\u3085\u3087\u308e\u3095\u3096\u31f0\u31f1\u31f2\u31f3\u31f4\u31f5\u31f6\u31f7\u31f8\u31f9\u31fa\u31fb\u31fc\u31fd\u31fe\u31ff\u3005\u303b\uff67\uff68\uff69\uff6a\uff6b\uff6c\uff6d\uff6e\uff6f\uff70\u201d\u3009\u300b\u300d\u300f\u3011\u3015\uff09\uff3d\uff5d\uff63")),wordWrapBreakBeforeCharacters:B(new y(135,"wordWrapBreakBeforeCharacters","([{\u2018\u201c\u3008\u300a\u300c\u300e\u3010\u3014\uff08\uff3b\uff5b\uff62\xa3\xa5\uff04\uffe1\uffe5+\uff0b")),wordWrapColumn:B(new E(136,"wordWrapColumn",80,1,1073741824,{markdownDescription:c.kg({key:"wordWrapColumn",comment:["- `editor.wordWrap` refers to a different setting and should not be localized.","- 'wordWrapColumn' and 'bounded' refer to values the different setting can take and should not be localized."]},"Controls the wrapping column of the editor when `#editor.wordWrap#` is `wordWrapColumn` or `bounded`.")})),wordWrapOverride1:B(new R(137,"wordWrapOverride1","inherit",["off","on","inherit"])),wordWrapOverride2:B(new R(138,"wordWrapOverride2","inherit",["off","on","inherit"])),editorClassName:B(new class extends m{constructor(){super(143)}compute(e,t,i){const s=["monaco-editor"];return t.get(39)&&s.push(t.get(39)),e.extraEditorClassName&&s.push(e.extraEditorClassName),"default"===t.get(74)?s.push("mouse-default"):"copy"===t.get(74)&&s.push("mouse-copy"),t.get(112)&&s.push("showUnused"),t.get(141)&&s.push("showDeprecated"),s.join(" ")}}),defaultColorDecorators:B(new v(148,"defaultColorDecorators",!1,{markdownDescription:c.kg("defaultColorDecorators","Controls whether inline color decorations should be shown using the default document color provider")})),pixelRatio:B(new class extends m{constructor(){super(144)}compute(e,t,i){return e.pixelRatio}}),tabFocusMode:B(new v(145,"tabFocusMode",!1,{markdownDescription:c.kg("tabFocusMode","Controls whether the editor receives tabs or defers them to the workbench for navigation.")})),layoutInfo:B(new I),wrappingInfo:B(new class extends m{constructor(){super(147)}compute(e,t,i){const s=t.get(146);return{isDominatedByLongLines:e.isDominatedByLongLines,isWordWrapMinified:s.isWordWrapMinified,isViewportWrapping:s.isViewportWrapping,wrappingColumn:s.wrappingColumn}}}),wrappingIndent:B(new class extends u{constructor(){super(139,"wrappingIndent",1,{"editor.wrappingIndent":{type:"string",enum:["none","same","indent","deepIndent"],enumDescriptions:[c.kg("wrappingIndent.none","No indentation. Wrapped lines begin at column 1."),c.kg("wrappingIndent.same","Wrapped lines get the same indentation as the parent."),c.kg("wrappingIndent.indent","Wrapped lines get +1 indentation toward the parent."),c.kg("wrappingIndent.deepIndent","Wrapped lines get +2 indentation toward the parent.")],description:c.kg("wrappingIndent","Controls the indentation of wrapped lines."),default:"same"}})}validate(e){switch(e){case"none":return 0;case"same":return 1;case"indent":return 2;case"deepIndent":return 3}return 1}compute(e,t,i){return 2===t.get(2)?0:i}}),wrappingStrategy:B(new class extends u{constructor(){super(140,"wrappingStrategy","simple",{"editor.wrappingStrategy":{enumDescriptions:[c.kg("wrappingStrategy.simple","Assumes that all characters are of the same width. This is a fast algorithm that works correctly for monospace fonts and certain scripts (like Latin characters) where glyphs are of equal width."),c.kg("wrappingStrategy.advanced","Delegates wrapping points computation to the browser. This is a slow algorithm, that might cause freezes for large files, but it works correctly in all cases.")],type:"string",enum:["simple","advanced"],default:"simple",description:c.kg("wrappingStrategy","Controls the algorithm that computes wrapping points. Note that when in accessibility mode, advanced will be used for the best experience.")}})}validate(e){return w(e,"simple",["simple","advanced"])}compute(e,t,i){return 2===t.get(2)?"advanced":i}})}},87958:(e,t,i)=>{"use strict";i.d(t,{C:()=>d,a0:()=>p,dQ:()=>h,nb:()=>u,rm:()=>g,un:()=>l});var s=i(66782),n=i(51241),r=i(5662),o=i(49154),a=i(22311),c=i(94958);function l(e,t){return void 0!==t?new m(new a.nA(e,void 0,t),t,void 0,void 0,void 0,n.nx):new m(new a.nA(void 0,void 0,e),e,void 0,void 0,void 0,n.nx)}function h(e,t,i){return new f(new a.nA(e,void 0,t),t,void 0,void 0,void 0,n.nx,i)}function d(e,t){return new m(new a.nA(e.owner,e.debugName,e.debugReferenceFn),t,void 0,void 0,e.onLastObserverRemoved,e.equalsFn??n.nx)}function u(e,t){return new m(new a.nA(e.owner,e.debugName,void 0),t,e.createEmptyChangeSummary,e.handleChange,void 0,e.equalityComparer??n.nx)}function g(e,t){let i,s;void 0===t?(i=e,s=void 0):(s=e,i=t);const o=new r.Cm;return new m(new a.nA(s,void 0,i),(e=>(o.clear(),i(e,o))),void 0,void 0,(()=>o.dispose()),n.nx)}function p(e,t){let i,s,o;return void 0===t?(i=e,s=void 0):(s=e,i=t),new m(new a.nA(s,void 0,i),(e=>{o?o.clear():o=new r.Cm;const t=i(e);return t&&o.add(t),t}),void 0,void 0,(()=>{o&&(o.dispose(),o=void 0)}),n.nx)}(0,o.N2)(d);class m extends o.ZK{get debugName(){return this._debugNameData.getDebugName(this)??"(anonymous)"}constructor(e,t,i,s,n=void 0,r){super(),this._debugNameData=e,this._computeFn=t,this.createChangeSummary=i,this._handleChange=s,this._handleLastObserverRemoved=n,this._equalityComparator=r,this.state=0,this.value=void 0,this.updateCount=0,this.dependencies=new Set,this.dependenciesToBeRemoved=new Set,this.changeSummary=void 0,this.changeSummary=this.createChangeSummary?.(),(0,c.tZ)()?.handleDerivedCreated(this)}onLastObserverRemoved(){this.state=0,this.value=void 0;for(const e of this.dependencies)e.removeObserver(this);this.dependencies.clear(),this._handleLastObserverRemoved?.()}get(){if(0===this.observers.size){const e=this._computeFn(this,this.createChangeSummary?.());return this.onLastObserverRemoved(),e}do{if(1===this.state)for(const e of this.dependencies)if(e.reportChanges(),2===this.state)break;1===this.state&&(this.state=3),this._recomputeIfNeeded()}while(3!==this.state);return this.value}_recomputeIfNeeded(){if(3===this.state)return;const e=this.dependenciesToBeRemoved;this.dependenciesToBeRemoved=this.dependencies,this.dependencies=e;const t=0!==this.state,i=this.value;this.state=3;const s=this.changeSummary;this.changeSummary=this.createChangeSummary?.();try{this.value=this._computeFn(this,s)}finally{for(const e of this.dependenciesToBeRemoved)e.removeObserver(this);this.dependenciesToBeRemoved.clear()}const n=t&&!this._equalityComparator(i,this.value);if((0,c.tZ)()?.handleDerivedRecomputed(this,{oldValue:i,newValue:this.value,change:void 0,didChange:n,hadValue:t}),n)for(const r of this.observers)r.handleChange(this,void 0)}toString(){return`LazyDerived<${this.debugName}>`}beginUpdate(e){this.updateCount++;const t=1===this.updateCount;if(3===this.state&&(this.state=1,!t))for(const i of this.observers)i.handlePossibleChange(this);if(t)for(const i of this.observers)i.beginUpdate(this)}endUpdate(e){if(this.updateCount--,0===this.updateCount){const e=[...this.observers];for(const t of e)t.endUpdate(this)}(0,s.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){if(3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){this.state=1;for(const e of this.observers)e.handlePossibleChange(this)}}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){const i=!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary),s=3===this.state;if(i&&(1===this.state||s)&&(this.state=2,s))for(const e of this.observers)e.handlePossibleChange(this)}}readObservable(e){e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}addObserver(e){const t=!this.observers.has(e)&&this.updateCount>0;super.addObserver(e),t&&e.beginUpdate(this)}removeObserver(e){const t=this.observers.has(e)&&this.updateCount>0;super.removeObserver(e),t&&e.endUpdate(this)}}class f extends m{constructor(e,t,i,s,n=void 0,r,o){super(e,t,i,s,n,r),this.set=o}}},88415:(e,t,i)=>{"use strict";i.d(t,{GS:()=>E});var s,n=i(90766),r=i(5662),o=i(74320),a=i(4853),c=i(62083),l=i(84001),h=i(14718),d=i(63591),u=i(9711),g=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},p=function(e,t){return function(i,s){t(i,s,e)}};class m{constructor(e){this.name=e}select(e,t,i){if(0===i.length)return 0;const s=i[0].score[0];for(let n=0;na&&s.type===i[c].completion.kind&&s.insertText===i[c].completion.insertText&&(a=s.touch,o=c),i[c].completion.preselect&&-1===r)return c}return-1!==o?o:-1!==r?r:0}toJSON(){return this._cache.toJSON()}fromJSON(e){this._cache.clear();for(const[t,i]of e)i.touch=0,i.type="number"===typeof i.type?i.type:c.HC.fromString(i.type),this._cache.set(t,i);this._seq=this._cache.size}}class v extends m{constructor(){super("recentlyUsedByPrefix"),this._trie=a.cB.forStrings(),this._seq=0}memorize(e,t,i){const{word:s}=e.getWordUntilPosition(t),n=`${e.getLanguageId()}/${s}`;this._trie.set(n,{type:i.completion.kind,insertText:i.completion.insertText,touch:this._seq++})}select(e,t,i){const{word:s}=e.getWordUntilPosition(t);if(!s)return super.select(e,t,i);const n=`${e.getLanguageId()}/${s}`;let r=this._trie.get(n);if(r||(r=this._trie.findSubstr(n)),r)for(let o=0;oe.push([i,t]))),e.sort(((e,t)=>-(e[1].touch-t[1].touch))).forEach(((e,t)=>e[1].touch=t)),e.slice(0,200)}fromJSON(e){if(this._trie.clear(),e.length>0){this._seq=e[0][1].touch+1;for(const[t,i]of e)i.type="number"===typeof i.type?i.type:c.HC.fromString(i.type),this._trie.set(t,i)}}}let C=class{static{s=this}static{this._strategyCtors=new Map([["recentlyUsedByPrefix",v],["recentlyUsed",_],["first",f]])}static{this._storagePrefix="suggest/memories"}constructor(e,t){this._storageService=e,this._configService=t,this._disposables=new r.Cm,this._persistSoon=new n.uC((()=>this._saveState()),500),this._disposables.add(e.onWillSaveState((e=>{e.reason===u.LP.SHUTDOWN&&this._saveState()})))}dispose(){this._disposables.dispose(),this._persistSoon.dispose()}memorize(e,t,i){this._withStrategy(e,t).memorize(e,t,i),this._persistSoon.schedule()}select(e,t,i){return this._withStrategy(e,t).select(e,t,i)}_withStrategy(e,t){const i=this._configService.getValue("editor.suggestSelection",{overrideIdentifier:e.getLanguageIdAtPosition(t.lineNumber,t.column),resource:e.uri});if(this._strategy?.name!==i){this._saveState();const e=s._strategyCtors.get(i)||f;this._strategy=new e;try{const e=this._configService.getValue("editor.suggest.shareSuggestSelections")?0:1,t=this._storageService.get(`${s._storagePrefix}/${i}`,e);t&&this._strategy.fromJSON(JSON.parse(t))}catch(n){}}return this._strategy}_saveState(){if(this._strategy){const e=this._configService.getValue("editor.suggest.shareSuggestSelections")?0:1,t=JSON.stringify(this._strategy);this._storageService.store(`${s._storagePrefix}/${this._strategy.name}`,t,e,1)}}};C=s=g([p(0,u.CS),p(1,l.pG)],C);const E=(0,d.u1)("ISuggestMemories");(0,h.v)(E,C,1)},88443:(e,t,i)=>{"use strict";i.d(t,{c:()=>u});var s=i(8597),n=i(23034),r=i(91581),o=i(17390),a=i(41234),c=(i(10713),i(78209)),l=i(5662),h=i(42904);const d=c.kg("defaultLabel","input");class u extends o.x{constructor(e,t,i){super(),this.fixFocusOnOptionClickEnabled=!0,this.imeSessionInProgress=!1,this.additionalTogglesDisposables=this._register(new l.HE),this.additionalToggles=[],this._onDidOptionChange=this._register(new a.vl),this.onDidOptionChange=this._onDidOptionChange.event,this._onKeyDown=this._register(new a.vl),this.onKeyDown=this._onKeyDown.event,this._onMouseDown=this._register(new a.vl),this.onMouseDown=this._onMouseDown.event,this._onInput=this._register(new a.vl),this._onKeyUp=this._register(new a.vl),this._onCaseSensitiveKeyDown=this._register(new a.vl),this.onCaseSensitiveKeyDown=this._onCaseSensitiveKeyDown.event,this._onRegexKeyDown=this._register(new a.vl),this.onRegexKeyDown=this._onRegexKeyDown.event,this._lastHighlightFindOptions=0,this.placeholder=i.placeholder||"",this.validation=i.validation,this.label=i.label||d,this.showCommonFindToggles=!!i.showCommonFindToggles;const o=i.appendCaseSensitiveLabel||"",c=i.appendWholeWordsLabel||"",u=i.appendRegexLabel||"",g=i.history||[],p=!!i.flexibleHeight,m=!!i.flexibleWidth,f=i.flexibleMaxHeight;this.domNode=document.createElement("div"),this.domNode.classList.add("monaco-findInput"),this.inputBox=this._register(new r.mJ(this.domNode,t,{placeholder:this.placeholder||"",ariaLabel:this.label||"",validationOptions:{validation:this.validation},history:g,showHistoryHint:i.showHistoryHint,flexibleHeight:p,flexibleWidth:m,flexibleMaxHeight:f,inputBoxStyles:i.inputBoxStyles}));const _=this._register((0,h.bW)());if(this.showCommonFindToggles){this.regex=this._register(new n.Ix({appendTitle:u,isChecked:!1,hoverDelegate:_,...i.toggleStyles})),this._register(this.regex.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this._register(this.regex.onKeyDown((e=>{this._onRegexKeyDown.fire(e)}))),this.wholeWords=this._register(new n.nV({appendTitle:c,isChecked:!1,hoverDelegate:_,...i.toggleStyles})),this._register(this.wholeWords.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this.caseSensitive=this._register(new n.bc({appendTitle:o,isChecked:!1,hoverDelegate:_,...i.toggleStyles})),this._register(this.caseSensitive.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this._register(this.caseSensitive.onKeyDown((e=>{this._onCaseSensitiveKeyDown.fire(e)})));const e=[this.caseSensitive.domNode,this.wholeWords.domNode,this.regex.domNode];this.onkeydown(this.domNode,(t=>{if(t.equals(15)||t.equals(17)||t.equals(9)){const i=e.indexOf(this.domNode.ownerDocument.activeElement);if(i>=0){let n=-1;t.equals(17)?n=(i+1)%e.length:t.equals(15)&&(n=0===i?e.length-1:i-1),t.equals(9)?(e[i].blur(),this.inputBox.focus()):n>=0&&e[n].focus(),s.fs.stop(t,!0)}}}))}this.controls=document.createElement("div"),this.controls.className="controls",this.controls.style.display=this.showCommonFindToggles?"":"none",this.caseSensitive&&this.controls.append(this.caseSensitive.domNode),this.wholeWords&&this.controls.appendChild(this.wholeWords.domNode),this.regex&&this.controls.appendChild(this.regex.domNode),this.setAdditionalToggles(i?.additionalToggles),this.controls&&this.domNode.appendChild(this.controls),e?.appendChild(this.domNode),this._register(s.ko(this.inputBox.inputElement,"compositionstart",(e=>{this.imeSessionInProgress=!0}))),this._register(s.ko(this.inputBox.inputElement,"compositionend",(e=>{this.imeSessionInProgress=!1,this._onInput.fire()}))),this.onkeydown(this.inputBox.inputElement,(e=>this._onKeyDown.fire(e))),this.onkeyup(this.inputBox.inputElement,(e=>this._onKeyUp.fire(e))),this.oninput(this.inputBox.inputElement,(e=>this._onInput.fire())),this.onmousedown(this.inputBox.inputElement,(e=>this._onMouseDown.fire(e)))}get onDidChange(){return this.inputBox.onDidChange}layout(e){this.inputBox.layout(),this.updateInputBoxPadding(e.collapsedFindWidget)}enable(){this.domNode.classList.remove("disabled"),this.inputBox.enable(),this.regex?.enable(),this.wholeWords?.enable(),this.caseSensitive?.enable();for(const e of this.additionalToggles)e.enable()}disable(){this.domNode.classList.add("disabled"),this.inputBox.disable(),this.regex?.disable(),this.wholeWords?.disable(),this.caseSensitive?.disable();for(const e of this.additionalToggles)e.disable()}setFocusInputOnOptionClick(e){this.fixFocusOnOptionClickEnabled=e}setEnabled(e){e?this.enable():this.disable()}setAdditionalToggles(e){for(const t of this.additionalToggles)t.domNode.remove();this.additionalToggles=[],this.additionalTogglesDisposables.value=new l.Cm;for(const t of e??[])this.additionalTogglesDisposables.value.add(t),this.controls.appendChild(t.domNode),this.additionalTogglesDisposables.value.add(t.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus()}))),this.additionalToggles.push(t);this.additionalToggles.length>0&&(this.controls.style.display=""),this.updateInputBoxPadding()}updateInputBoxPadding(e=!1){this.inputBox.paddingRight=e?0:(this.caseSensitive?.width()??0)+(this.wholeWords?.width()??0)+(this.regex?.width()??0)+this.additionalToggles.reduce(((e,t)=>e+t.width()),0)}getValue(){return this.inputBox.value}setValue(e){this.inputBox.value!==e&&(this.inputBox.value=e)}select(){this.inputBox.select()}focus(){this.inputBox.focus()}getCaseSensitive(){return this.caseSensitive?.checked??!1}setCaseSensitive(e){this.caseSensitive&&(this.caseSensitive.checked=e)}getWholeWords(){return this.wholeWords?.checked??!1}setWholeWords(e){this.wholeWords&&(this.wholeWords.checked=e)}getRegex(){return this.regex?.checked??!1}setRegex(e){this.regex&&(this.regex.checked=e,this.validate())}focusOnCaseSensitive(){this.caseSensitive?.focus()}highlightFindOptions(){this.domNode.classList.remove("highlight-"+this._lastHighlightFindOptions),this._lastHighlightFindOptions=1-this._lastHighlightFindOptions,this.domNode.classList.add("highlight-"+this._lastHighlightFindOptions)}validate(){this.inputBox.validate()}showMessage(e){this.inputBox.showMessage(e)}clearMessage(){this.inputBox.hideMessage()}}},88608:(e,t,i)=>{e.exports=function(){const e=i(94297);function t(t,i){return"json"===t.format?e.escapeJSONString(t,i):e.escapeYSONString(t,i)}function s(i,s){let n,r;return i.$key&&"yson"===s.format?(n=e.unescapeKeyValue(i.$value),r=e.unescapeKeyValue(i.$decoded_value)):(n=i.$value,r=i.$decoded_value),i.$binary?s.binaryAsHex?e.escapeYSONBinaryString(s,n):t(s,n):s.showDecoded?e.escapeJSONString(s,r):t(s,n)}return s.isScalar=!0,s}},88807:(e,t,i)=>{"use strict";i.d(t,{v:()=>a});var s=i(8597),n=i(92403),r=i(41234),o=i(5662);class a{constructor(){let e;this._onDidWillResize=new r.vl,this.onDidWillResize=this._onDidWillResize.event,this._onDidResize=new r.vl,this.onDidResize=this._onDidResize.event,this._sashListener=new o.Cm,this._size=new s.fg(0,0),this._minSize=new s.fg(0,0),this._maxSize=new s.fg(Number.MAX_SAFE_INTEGER,Number.MAX_SAFE_INTEGER),this.domNode=document.createElement("div"),this._eastSash=new n.m(this.domNode,{getVerticalSashLeft:()=>this._size.width},{orientation:0}),this._westSash=new n.m(this.domNode,{getVerticalSashLeft:()=>0},{orientation:0}),this._northSash=new n.m(this.domNode,{getHorizontalSashTop:()=>0},{orientation:1,orthogonalEdge:n.B.North}),this._southSash=new n.m(this.domNode,{getHorizontalSashTop:()=>this._size.height},{orientation:1,orthogonalEdge:n.B.South}),this._northSash.orthogonalStartSash=this._westSash,this._northSash.orthogonalEndSash=this._eastSash,this._southSash.orthogonalStartSash=this._westSash,this._southSash.orthogonalEndSash=this._eastSash;let t=0,i=0;this._sashListener.add(r.Jh.any(this._northSash.onDidStart,this._eastSash.onDidStart,this._southSash.onDidStart,this._westSash.onDidStart)((()=>{void 0===e&&(this._onDidWillResize.fire(),e=this._size,t=0,i=0)}))),this._sashListener.add(r.Jh.any(this._northSash.onDidEnd,this._eastSash.onDidEnd,this._southSash.onDidEnd,this._westSash.onDidEnd)((()=>{void 0!==e&&(e=void 0,t=0,i=0,this._onDidResize.fire({dimension:this._size,done:!0}))}))),this._sashListener.add(this._eastSash.onDidChange((s=>{e&&(i=s.currentX-s.startX,this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,east:!0}))}))),this._sashListener.add(this._westSash.onDidChange((s=>{e&&(i=-(s.currentX-s.startX),this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,west:!0}))}))),this._sashListener.add(this._northSash.onDidChange((s=>{e&&(t=-(s.currentY-s.startY),this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,north:!0}))}))),this._sashListener.add(this._southSash.onDidChange((s=>{e&&(t=s.currentY-s.startY,this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,south:!0}))}))),this._sashListener.add(r.Jh.any(this._eastSash.onDidReset,this._westSash.onDidReset)((e=>{this._preferredSize&&(this.layout(this._size.height,this._preferredSize.width),this._onDidResize.fire({dimension:this._size,done:!0}))}))),this._sashListener.add(r.Jh.any(this._northSash.onDidReset,this._southSash.onDidReset)((e=>{this._preferredSize&&(this.layout(this._preferredSize.height,this._size.width),this._onDidResize.fire({dimension:this._size,done:!0}))})))}dispose(){this._northSash.dispose(),this._southSash.dispose(),this._eastSash.dispose(),this._westSash.dispose(),this._sashListener.dispose(),this._onDidResize.dispose(),this._onDidWillResize.dispose(),this.domNode.remove()}enableSashes(e,t,i,s){this._northSash.state=e?3:0,this._eastSash.state=t?3:0,this._southSash.state=i?3:0,this._westSash.state=s?3:0}layout(e=this.size.height,t=this.size.width){const{height:i,width:n}=this._minSize,{height:r,width:o}=this._maxSize;e=Math.max(i,Math.min(r,e)),t=Math.max(n,Math.min(o,t));const a=new s.fg(t,e);s.fg.equals(a,this._size)||(this.domNode.style.height=e+"px",this.domNode.style.width=t+"px",this._size=a,this._northSash.layout(),this._eastSash.layout(),this._southSash.layout(),this._westSash.layout())}clearSashHoverState(){this._eastSash.clearSashHoverState(),this._westSash.clearSashHoverState(),this._northSash.clearSashHoverState(),this._southSash.clearSashHoverState()}get size(){return this._size}set maxSize(e){this._maxSize=e}get maxSize(){return this._maxSize}set minSize(e){this._minSize=e}get minSize(){return this._minSize}set preferredSize(e){this._preferredSize=e}get preferredSize(){return this._preferredSize}}},88834:e=>{e.exports=function(e){var t=null==e?0:e.length;return t?e[t-1]:void 0}},88952:(e,t,i)=>{"use strict";var s=i(90766),n=i(5662),r=i(31450),o=i(83069),a=i(36677),c=i(75326),l=i(60002),h=i(16223),d=i(87289),u=i(78209),g=i(27195),p=i(66261),m=i(47612);const f=(0,p.x1A)("editorOverviewRuler.bracketMatchForeground","#A0A0A0",u.kg("overviewRulerBracketMatchForeground","Overview ruler marker color for matching brackets."));class _ extends r.ks{constructor(){super({id:"editor.action.jumpToBracket",label:u.kg("smartSelect.jumpBracket","Go to Bracket"),alias:"Go to Bracket",precondition:void 0,kbOpts:{kbExpr:l.R.editorTextFocus,primary:3165,weight:100}})}run(e,t){b.get(t)?.jumpToBracket()}}class v extends r.ks{constructor(){super({id:"editor.action.selectToBracket",label:u.kg("smartSelect.selectToBracket","Select to Bracket"),alias:"Select to Bracket",precondition:void 0,metadata:{description:u.aS("smartSelect.selectToBracketDescription","Select the text inside and including the brackets or curly braces"),args:[{name:"args",schema:{type:"object",properties:{selectBrackets:{type:"boolean",default:!0}}}}]}})}run(e,t,i){let s=!0;i&&!1===i.selectBrackets&&(s=!1),b.get(t)?.selectToBracket(s)}}class C extends r.ks{constructor(){super({id:"editor.action.removeBrackets",label:u.kg("smartSelect.removeBrackets","Remove Brackets"),alias:"Remove Brackets",precondition:void 0,kbOpts:{kbExpr:l.R.editorTextFocus,primary:2561,weight:100}})}run(e,t){b.get(t)?.removeBrackets(this.id)}}class E{constructor(e,t,i){this.position=e,this.brackets=t,this.options=i}}class b extends n.jG{static{this.ID="editor.contrib.bracketMatchingController"}static get(e){return e.getContribution(b.ID)}constructor(e){super(),this._editor=e,this._lastBracketsData=[],this._lastVersionId=0,this._decorations=this._editor.createDecorationsCollection(),this._updateBracketsSoon=this._register(new s.uC((()=>this._updateBrackets()),50)),this._matchBrackets=this._editor.getOption(72),this._updateBracketsSoon.schedule(),this._register(e.onDidChangeCursorPosition((e=>{"never"!==this._matchBrackets&&this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeModelContent((e=>{this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeModel((e=>{this._lastBracketsData=[],this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeModelLanguageConfiguration((e=>{this._lastBracketsData=[],this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeConfiguration((e=>{e.hasChanged(72)&&(this._matchBrackets=this._editor.getOption(72),this._decorations.clear(),this._lastBracketsData=[],this._lastVersionId=0,this._updateBracketsSoon.schedule())}))),this._register(e.onDidBlurEditorWidget((()=>{this._updateBracketsSoon.schedule()}))),this._register(e.onDidFocusEditorWidget((()=>{this._updateBracketsSoon.schedule()})))}jumpToBracket(){if(!this._editor.hasModel())return;const e=this._editor.getModel(),t=this._editor.getSelections().map((t=>{const i=t.getStartPosition(),s=e.bracketPairs.matchBracket(i);let n=null;if(s)s[0].containsPosition(i)&&!s[1].containsPosition(i)?n=s[1].getStartPosition():s[1].containsPosition(i)&&(n=s[0].getStartPosition());else{const t=e.bracketPairs.findEnclosingBrackets(i);if(t)n=t[1].getStartPosition();else{const t=e.bracketPairs.findNextBracket(i);t&&t.range&&(n=t.range.getStartPosition())}}return n?new c.L(n.lineNumber,n.column,n.lineNumber,n.column):new c.L(i.lineNumber,i.column,i.lineNumber,i.column)}));this._editor.setSelections(t),this._editor.revealRange(t[0])}selectToBracket(e){if(!this._editor.hasModel())return;const t=this._editor.getModel(),i=[];this._editor.getSelections().forEach((s=>{const n=s.getStartPosition();let r=t.bracketPairs.matchBracket(n);if(!r&&(r=t.bracketPairs.findEnclosingBrackets(n),!r)){const e=t.bracketPairs.findNextBracket(n);e&&e.range&&(r=t.bracketPairs.matchBracket(e.range.getStartPosition()))}let o=null,l=null;if(r){r.sort(a.Q.compareRangesUsingStarts);const[t,i]=r;if(o=e?t.getStartPosition():t.getEndPosition(),l=e?i.getEndPosition():i.getStartPosition(),i.containsPosition(n)){const e=o;o=l,l=e}}o&&l&&i.push(new c.L(o.lineNumber,o.column,l.lineNumber,l.column))})),i.length>0&&(this._editor.setSelections(i),this._editor.revealRange(i[0]))}removeBrackets(e){if(!this._editor.hasModel())return;const t=this._editor.getModel();this._editor.getSelections().forEach((i=>{const s=i.getPosition();let n=t.bracketPairs.matchBracket(s);n||(n=t.bracketPairs.findEnclosingBrackets(s)),n&&(this._editor.pushUndoStop(),this._editor.executeEdits(e,[{range:n[0],text:""},{range:n[1],text:""}]),this._editor.pushUndoStop())}))}static{this._DECORATION_OPTIONS_WITH_OVERVIEW_RULER=d.kI.register({description:"bracket-match-overview",stickiness:1,className:"bracket-match",overviewRuler:{color:(0,m.Yf)(f),position:h.A5.Center}})}static{this._DECORATION_OPTIONS_WITHOUT_OVERVIEW_RULER=d.kI.register({description:"bracket-match-no-overview",stickiness:1,className:"bracket-match"})}_updateBrackets(){if("never"===this._matchBrackets)return;this._recomputeBrackets();const e=[];let t=0;for(const i of this._lastBracketsData){const s=i.brackets;s&&(e[t++]={range:s[0],options:i.options},e[t++]={range:s[1],options:i.options})}this._decorations.set(e)}_recomputeBrackets(){if(!this._editor.hasModel()||!this._editor.hasWidgetFocus())return this._lastBracketsData=[],void(this._lastVersionId=0);const e=this._editor.getSelections();if(e.length>100)return this._lastBracketsData=[],void(this._lastVersionId=0);const t=this._editor.getModel(),i=t.getVersionId();let s=[];this._lastVersionId===i&&(s=this._lastBracketsData);const n=[];let r=0;for(let o=0,d=e.length;o1&&n.sort(o.y.compare);const a=[];let c=0,l=0;const h=s.length;for(let o=0,d=n.length;o{"use strict";i.d(t,{pG:()=>x,_Q:()=>k,dg:()=>b});var s=i(88443),n=i(8597),r=i(35315),o=i(91581),a=i(17390),c=i(10350),l=i(41234),h=(i(10713),i(78209)),d=i(42904);const u=h.kg("defaultLabel","input"),g=h.kg("label.preserveCaseToggle","Preserve Case");class p extends r.l{constructor(e){super({icon:c.W.preserveCase,title:g+e.appendTitle,isChecked:e.isChecked,hoverDelegate:e.hoverDelegate??(0,d.nZ)("element"),inputActiveOptionBorder:e.inputActiveOptionBorder,inputActiveOptionForeground:e.inputActiveOptionForeground,inputActiveOptionBackground:e.inputActiveOptionBackground})}}class m extends a.x{constructor(e,t,i,s){super(),this._showOptionButtons=i,this.fixFocusOnOptionClickEnabled=!0,this.cachedOptionsWidth=0,this._onDidOptionChange=this._register(new l.vl),this.onDidOptionChange=this._onDidOptionChange.event,this._onKeyDown=this._register(new l.vl),this.onKeyDown=this._onKeyDown.event,this._onMouseDown=this._register(new l.vl),this._onInput=this._register(new l.vl),this._onKeyUp=this._register(new l.vl),this._onPreserveCaseKeyDown=this._register(new l.vl),this.onPreserveCaseKeyDown=this._onPreserveCaseKeyDown.event,this.contextViewProvider=t,this.placeholder=s.placeholder||"",this.validation=s.validation,this.label=s.label||u;const r=s.appendPreserveCaseLabel||"",a=s.history||[],c=!!s.flexibleHeight,h=!!s.flexibleWidth,d=s.flexibleMaxHeight;this.domNode=document.createElement("div"),this.domNode.classList.add("monaco-findInput"),this.inputBox=this._register(new o.mJ(this.domNode,this.contextViewProvider,{ariaLabel:this.label||"",placeholder:this.placeholder||"",validationOptions:{validation:this.validation},history:a,showHistoryHint:s.showHistoryHint,flexibleHeight:c,flexibleWidth:h,flexibleMaxHeight:d,inputBoxStyles:s.inputBoxStyles})),this.preserveCase=this._register(new p({appendTitle:r,isChecked:!1,...s.toggleStyles})),this._register(this.preserveCase.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this._register(this.preserveCase.onKeyDown((e=>{this._onPreserveCaseKeyDown.fire(e)}))),this._showOptionButtons?this.cachedOptionsWidth=this.preserveCase.width():this.cachedOptionsWidth=0;const g=[this.preserveCase.domNode];this.onkeydown(this.domNode,(e=>{if(e.equals(15)||e.equals(17)||e.equals(9)){const t=g.indexOf(this.domNode.ownerDocument.activeElement);if(t>=0){let i=-1;e.equals(17)?i=(t+1)%g.length:e.equals(15)&&(i=0===t?g.length-1:t-1),e.equals(9)?(g[t].blur(),this.inputBox.focus()):i>=0&&g[i].focus(),n.fs.stop(e,!0)}}}));const m=document.createElement("div");m.className="controls",m.style.display=this._showOptionButtons?"block":"none",m.appendChild(this.preserveCase.domNode),this.domNode.appendChild(m),e?.appendChild(this.domNode),this.onkeydown(this.inputBox.inputElement,(e=>this._onKeyDown.fire(e))),this.onkeyup(this.inputBox.inputElement,(e=>this._onKeyUp.fire(e))),this.oninput(this.inputBox.inputElement,(e=>this._onInput.fire())),this.onmousedown(this.inputBox.inputElement,(e=>this._onMouseDown.fire(e)))}enable(){this.domNode.classList.remove("disabled"),this.inputBox.enable(),this.preserveCase.enable()}disable(){this.domNode.classList.add("disabled"),this.inputBox.disable(),this.preserveCase.disable()}setEnabled(e){e?this.enable():this.disable()}select(){this.inputBox.select()}focus(){this.inputBox.focus()}getPreserveCase(){return this.preserveCase.checked}setPreserveCase(e){this.preserveCase.checked=e}focusOnPreserve(){this.preserveCase.focus()}validate(){this.inputBox?.validate()}set width(e){this.inputBox.paddingRight=this.cachedOptionsWidth,this.domNode.style.width=e+"px"}dispose(){super.dispose()}}var f=i(32848),_=i(59261),v=i(5662),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},E=function(e,t){return function(i,s){t(i,s,e)}};const b=new f.N1("suggestWidgetVisible",!1,(0,h.kg)("suggestWidgetVisible","Whether suggestion are visible")),S="historyNavigationWidgetFocus",y="historyNavigationForwardsEnabled",w="historyNavigationBackwardsEnabled";let R;const L=[];function T(e,t){if(L.includes(t))throw new Error("Cannot register the same widget multiple times");L.push(t);const i=new v.Cm,s=new f.N1(S,!1).bindTo(e),r=new f.N1(y,!0).bindTo(e),o=new f.N1(w,!0).bindTo(e),a=()=>{s.set(!0),R=t},c=()=>{s.set(!1),R===t&&(R=void 0)};return(0,n.X7)(t.element)&&a(),i.add(t.onDidFocus((()=>a()))),i.add(t.onDidBlur((()=>c()))),i.add((0,v.s)((()=>{L.splice(L.indexOf(t),1),c()}))),{historyNavigationForwardsEnablement:r,historyNavigationBackwardsEnablement:o,dispose(){i.dispose()}}}let x=class extends s.c{constructor(e,t,i,s){super(e,t,i);const n=this._register(s.createScoped(this.inputBox.element));this._register(T(n,this.inputBox))}};x=C([E(3,f.fN)],x);let k=class extends m{constructor(e,t,i,s,n=!1){super(e,t,n,i);const r=this._register(s.createScoped(this.inputBox.element));this._register(T(r,this.inputBox))}};k=C([E(3,f.fN)],k),_.f.registerCommandAndKeybindingRule({id:"history.showPrevious",weight:200,when:f.M$.and(f.M$.has(S),f.M$.equals(w,!0),f.M$.not("isComposing"),b.isEqualTo(!1)),primary:16,secondary:[528],handler:e=>{R?.showPreviousValue()}}),_.f.registerCommandAndKeybindingRule({id:"history.showNext",weight:200,when:f.M$.and(f.M$.has(S),f.M$.equals(y,!0),f.M$.not("isComposing"),b.isEqualTo(!1)),primary:18,secondary:[530],handler:e=>{R?.showNextValue()}})},89336:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"kotlin",extensions:[".kt",".kts"],aliases:["Kotlin","kotlin"],mimetypes:["text/x-kotlin-source","text/x-kotlin"],loader:()=>i.e(62350).then(i.bind(i,62350))})},89403:(e,t,i)=>{"use strict";i.d(t,{B6:()=>y,Fd:()=>v,LC:()=>m,P8:()=>p,Pi:()=>g,er:()=>d,iZ:()=>C,n4:()=>u,o1:()=>E,pD:()=>f,su:()=>l,uJ:()=>_});var s=i(79326),n=i(36456),r=i(74027),o=i(98067),a=i(91508),c=i(79400);function l(e){return(0,c.I)(e,!0)}class h{constructor(e){this._ignorePathCasing=e}compare(e,t,i=!1){return e===t?0:(0,a.UD)(this.getComparisonKey(e,i),this.getComparisonKey(t,i))}isEqual(e,t,i=!1){return e===t||!(!e||!t)&&this.getComparisonKey(e,i)===this.getComparisonKey(t,i)}getComparisonKey(e,t=!1){return e.with({path:this._ignorePathCasing(e)?e.path.toLowerCase():void 0,fragment:t?null:void 0}).toString()}isEqualOrParent(e,t,i=!1){if(e.scheme===t.scheme){if(e.scheme===n.ny.file)return s._1(l(e),l(t),this._ignorePathCasing(e))&&e.query===t.query&&(i||e.fragment===t.fragment);if(b(e.authority,t.authority))return s._1(e.path,t.path,this._ignorePathCasing(e),"/")&&e.query===t.query&&(i||e.fragment===t.fragment)}return!1}joinPath(e,...t){return c.r.joinPath(e,...t)}basenameOrAuthority(e){return p(e)||e.authority}basename(e){return r.SA.basename(e.path)}extname(e){return r.SA.extname(e.path)}dirname(e){if(0===e.path.length)return e;let t;return e.scheme===n.ny.file?t=c.r.file(r.pD(l(e))).path:(t=r.SA.dirname(e.path),e.authority&&t.length&&47!==t.charCodeAt(0)&&(console.error(`dirname("${e.toString})) resulted in a relative path`),t="/")),e.with({path:t})}normalizePath(e){if(!e.path.length)return e;let t;return t=e.scheme===n.ny.file?c.r.file(r.S8(l(e))).path:r.SA.normalize(e.path),e.with({path:t})}relativePath(e,t){if(e.scheme!==t.scheme||!b(e.authority,t.authority))return;if(e.scheme===n.ny.file){const i=r.V8(l(e),l(t));return o.uF?s.TH(i):i}let i=e.path||"/";const a=t.path||"/";if(this._ignorePathCasing(e)){let e=0;for(const t=Math.min(i.length,a.length);es.Zn(i).length&&i[i.length-1]===t}{const t=e.path;return t.length>1&&47===t.charCodeAt(t.length-1)&&!/^[a-zA-Z]:(\/$|\\$)/.test(e.fsPath)}}removeTrailingPathSeparator(e,t=r.Vn){return S(e,t)?e.with({path:e.path.substr(0,e.path.length-1)}):e}addTrailingPathSeparator(e,t=r.Vn){let i=!1;if(e.scheme===n.ny.file){const n=l(e);i=void 0!==n&&n.length===s.Zn(n).length&&n[n.length-1]===t}else{t="/";const s=e.path;i=1===s.length&&47===s.charCodeAt(s.length-1)}return i||S(e,t)?e:e.with({path:e.path+"/"})}}const d=new h((()=>!1)),u=(new h((e=>e.scheme!==n.ny.file||!o.j9)),new h((e=>!0)),d.isEqual.bind(d)),g=(d.isEqualOrParent.bind(d),d.getComparisonKey.bind(d),d.basenameOrAuthority.bind(d)),p=d.basename.bind(d),m=d.extname.bind(d),f=d.dirname.bind(d),_=d.joinPath.bind(d),v=d.normalizePath.bind(d),C=d.relativePath.bind(d),E=d.resolvePath.bind(d),b=(d.isAbsolutePath.bind(d),d.isEqualAuthority.bind(d)),S=d.hasTrailingPathSeparator.bind(d);d.removeTrailingPathSeparator.bind(d),d.addTrailingPathSeparator.bind(d);var y;!function(e){e.META_DATA_LABEL="label",e.META_DATA_DESCRIPTION="description",e.META_DATA_SIZE="size",e.META_DATA_MIME="mime",e.parseMetaData=function(t){const i=new Map;t.path.substring(t.path.indexOf(";")+1,t.path.lastIndexOf(";")).split(";").forEach((e=>{const[t,s]=e.split(":");t&&s&&i.set(t,s)}));const s=t.path.substring(0,t.path.indexOf(";"));return s&&i.set(e.META_DATA_MIME,s),i}}(y||(y={}))},89506:(e,t,i)=>{"use strict";i.d(t,{d:()=>g});var s=i(8597),n=i(5646),r=i(72962),o=i(25154),a=i(36921),c=i(41234);class l extends a.LN{constructor(e,t){super(),this._onDidChangeVisibility=this._register(new c.vl),this.onDidChangeVisibility=this._onDidChangeVisibility.event,this._element=(0,s.BC)(e,(0,s.$)(".monaco-dropdown")),this._label=(0,s.BC)(this._element,(0,s.$)(".dropdown-label"));let i=t.labelRenderer;i||(i=e=>(e.textContent=t.label||"",null));for(const r of[s.Bx.CLICK,s.Bx.MOUSE_DOWN,o.B.Tap])this._register((0,s.ko)(this.element,r,(e=>s.fs.stop(e,!0))));for(const r of[s.Bx.MOUSE_DOWN,o.B.Tap])this._register((0,s.ko)(this._label,r,(e=>{(0,s.Er)(e)&&(e.detail>1||0!==e.button)||(this.visible?this.hide():this.show())})));this._register((0,s.ko)(this._label,s.Bx.KEY_UP,(e=>{const t=new r.Z(e);(t.equals(3)||t.equals(10))&&(s.fs.stop(e,!0),this.visible?this.hide():this.show())})));const n=i(this._label);n&&this._register(n),this._register(o.q.addTarget(this._label))}get element(){return this._element}show(){this.visible||(this.visible=!0,this._onDidChangeVisibility.fire(!0))}hide(){this.visible&&(this.visible=!1,this._onDidChangeVisibility.fire(!1))}dispose(){super.dispose(),this.hide(),this.boxContainer&&(this.boxContainer.remove(),this.boxContainer=void 0),this.contents&&(this.contents.remove(),this.contents=void 0),this._label&&(this._label.remove(),this._label=void 0)}}class h extends l{constructor(e,t){super(e,t),this._options=t,this._actions=[],this.actions=t.actions||[]}set menuOptions(e){this._menuOptions=e}get menuOptions(){return this._menuOptions}get actions(){return this._options.actionProvider?this._options.actionProvider.getActions():this._actions}set actions(e){this._actions=e}show(){super.show(),this.element.classList.add("active"),this._options.contextMenuProvider.showContextMenu({getAnchor:()=>this.element,getActions:()=>this.actions,getActionsContext:()=>this.menuOptions?this.menuOptions.context:null,getActionViewItem:(e,t)=>this.menuOptions&&this.menuOptions.actionViewItemProvider?this.menuOptions.actionViewItemProvider(e,t):void 0,getKeyBinding:e=>this.menuOptions&&this.menuOptions.getKeyBinding?this.menuOptions.getKeyBinding(e):void 0,getMenuClassName:()=>this._options.menuClassName||"",onHide:()=>this.onHide(),actionRunner:this.menuOptions?this.menuOptions.actionRunner:void 0,anchorAlignment:this.menuOptions?this.menuOptions.anchorAlignment:0,domForShadowRoot:this._options.menuAsChild?this.element:void 0,skipTelemetry:this._options.skipTelemetry})}hide(){super.hide()}onHide(){this.hide(),this.element.classList.remove("active")}}var d=i(42904),u=i(48196);class g extends n.EH{constructor(e,t,i,s=Object.create(null)){super(null,e,s),this.actionItem=null,this._onDidChangeVisibility=this._register(new c.vl),this.onDidChangeVisibility=this._onDidChangeVisibility.event,this.menuActionsOrProvider=t,this.contextMenuProvider=i,this.options=s,this.options.actionRunner&&(this.actionRunner=this.options.actionRunner)}render(e){this.actionItem=e;const t=Array.isArray(this.menuActionsOrProvider),i={contextMenuProvider:this.contextMenuProvider,labelRenderer:e=>{this.element=(0,s.BC)(e,(0,s.$)("a.action-label"));let t=[];return"string"===typeof this.options.classNames?t=this.options.classNames.split(/\s+/g).filter((e=>!!e)):this.options.classNames&&(t=this.options.classNames),t.find((e=>"icon"===e))||t.push("codicon"),this.element.classList.add(...t),this.element.setAttribute("role","button"),this.element.setAttribute("aria-haspopup","true"),this.element.setAttribute("aria-expanded","false"),this._action.label&&this._register((0,u.i)().setupManagedHover(this.options.hoverDelegate??(0,d.nZ)("mouse"),this.element,this._action.label)),this.element.ariaLabel=this._action.label||"",null},menuAsChild:this.options.menuAsChild,actions:t?this.menuActionsOrProvider:void 0,actionProvider:t?void 0:this.menuActionsOrProvider,skipTelemetry:this.options.skipTelemetry};if(this.dropdownMenu=this._register(new h(e,i)),this._register(this.dropdownMenu.onDidChangeVisibility((e=>{this.element?.setAttribute("aria-expanded",`${e}`),this._onDidChangeVisibility.fire(e)}))),this.dropdownMenu.menuOptions={actionViewItemProvider:this.options.actionViewItemProvider,actionRunner:this.actionRunner,getKeyBinding:this.options.keybindingProvider,context:this._context},this.options.anchorAlignmentProvider){const e=this;this.dropdownMenu.menuOptions={...this.dropdownMenu.menuOptions,get anchorAlignment(){return e.options.anchorAlignmentProvider()}}}this.updateTooltip(),this.updateEnabled()}getTooltip(){let e=null;return this.action.tooltip?e=this.action.tooltip:this.action.label&&(e=this.action.label),e??void 0}setActionContext(e){super.setActionContext(e),this.dropdownMenu&&(this.dropdownMenu.menuOptions?this.dropdownMenu.menuOptions.context=e:this.dropdownMenu.menuOptions={context:e})}show(){this.dropdownMenu?.show()}updateEnabled(){const e=!this.action.enabled;this.actionItem?.classList.toggle("disabled",e),this.element?.classList.toggle("disabled",e)}}},89518:(e,t,i)=>{"use strict";var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,l=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of c(t))l.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u=class{constructor(e,t,i){this._onDidChange=new d.Emitter,this._languageId=e,this.setOptions(t),this.setModeConfiguration(i)}get onDidChange(){return this._onDidChange.event}get languageId(){return this._languageId}get options(){return this._options}get modeConfiguration(){return this._modeConfiguration}setOptions(e){this._options=e||Object.create(null),this._onDidChange.fire(this)}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(this)}},g={format:{tabSize:4,insertSpaces:!1,wrapLineLength:120,unformatted:'default": "a, abbr, acronym, b, bdo, big, br, button, cite, code, dfn, em, i, img, input, kbd, label, map, object, q, samp, select, small, span, strong, sub, sup, textarea, tt, var',contentUnformatted:"pre",indentInnerHtml:!1,preserveNewLines:!0,maxPreserveNewLines:void 0,indentHandlebars:!1,endWithNewline:!1,extraLiners:"head, body, /html",wrapAttributes:"auto"},suggest:{},data:{useDefaultDataProvider:!0}};function p(e){return{completionItems:!0,hovers:!0,documentSymbols:!0,links:!0,documentHighlights:!0,rename:!0,colors:!0,foldingRanges:!0,selectionRanges:!0,diagnostics:e===m,documentFormattingEdits:e===m,documentRangeFormattingEdits:e===m}}var m="html",f="handlebars",_="razor",v=w(m,g,p(m)),C=v.defaults,E=w(f,g,p(f)),b=E.defaults,S=w(_,g,p(_)),y=S.defaults;function w(e,t=g,s=p(e)){const n=new u(e,t,s);let r;const o=d.languages.onLanguage(e,(async()=>{r=(await i.e(68821).then(i.bind(i,68821))).setupMode(n)}));return{defaults:n,dispose(){o.dispose(),r?.dispose(),r=void 0}}}d.languages.html={htmlDefaults:C,razorDefaults:y,handlebarDefaults:b,htmlLanguageService:v,handlebarLanguageService:E,razorLanguageService:S,registerHTMLLanguageService:w}},89807:(e,t,i)=>{var s=i(26437),n=i(33609);e.exports=function(e){return e?s(n(e),0,4294967295):0}},89896:(e,t,i)=>{e.exports=i(34529)},89974:(e,t,i)=>{"use strict";i.d(t,{F:()=>V});var s=i(60712),n=i(59284),r=i(56993),o=i.n(r),a=i(53302),c=i(63126),l=i(72837);const h=JSON.parse('{"label_error":"Error","label_empty":"No data"}'),d=JSON.parse('{"label_error":"\u041e\u0448\u0438\u0431\u043a\u0430","label_empty":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445"}'),u=(0,l.N)({en:h,ru:d},"ydb-navigation-tree"),g=(0,a.o)("ydb-navigation-tree-view-empty");function p({level:e}){return(0,s.jsx)(c.G,{name:(0,s.jsx)("span",{className:g(),children:u("label_empty")}),level:e})}const m=(0,a.o)("ydb-navigation-tree-view-error");function f({level:e}){return(0,s.jsx)(c.G,{name:(0,s.jsx)("span",{className:m(),children:u("label_error")}),level:e})}var _=i(80953);const v=(0,a.o)("ydb-navigation-tree-view-loader");function C({level:e}){return(0,s.jsx)(c.G,{name:(0,s.jsx)("div",{className:v(),children:(0,s.jsx)(_.t,{size:"xs"})}),level:e})}function E(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M9.22 15.03s-.001 0 0 0a.75.75 0 0 0 1.06-1.06l-.47-.47H10a3.016 3.016 0 0 0 1.507-.405A2.999 2.999 0 0 0 13 10.5V7.896h.003a2.735 2.735 0 0 0 .785-.366 2.75 2.75 0 1 0-2.288.366V10.5A1.5 1.5 0 0 1 10 12h-.19l.47-.47s0 .001 0 0a.75.75 0 0 0-1.06-1.06l-.47.47-1.28 1.28a.75.75 0 0 0 0 1.06l1.75 1.75ZM5.72 2.97a.75.75 0 0 1 1.06 0l.47.47 1.28 1.28a.748.748 0 0 1 0 1.06L6.78 7.53c.001 0 0 0 0 0a.751.751 0 0 1-1.06-1.06L6.19 6H6a1.5 1.5 0 0 0-1.5 1.5v2.604a2.757 2.757 0 0 1 2 2.646 2.738 2.738 0 0 1-1.212 2.28 2.737 2.737 0 0 1-1.538.47A2.747 2.747 0 0 1 1 12.75a2.751 2.751 0 0 1 2-2.646V7.5a2.999 2.999 0 0 1 3-3h.19l-.47-.47a.75.75 0 0 1 0-1.06Zm-.908 9.121A1.246 1.246 0 0 1 5 12.75a1.25 1.25 0 1 1-.188-.659ZM11 5.25a1.25 1.25 0 1 1 2.5 0 1.25 1.25 0 0 1-2.5 0Z"})}))}function b(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M2.01033 3.79551C2.11275 2.787 2.96447 2 4 2H5.5H7H9H10.5H12C13.1046 2 14 2.89543 14 4V5.5V12C14 13.1046 13.1046 14 12 14H10.5H9H7H5.5H4C2.89543 14 2 13.1046 2 12V5.5V4C2 3.93096 2.0035 3.86275 2.01033 3.79551ZM10.5 12.5H11.5C12.0523 12.5 12.5 12.0523 12.5 11.5V5.5H10.5L10.5 12.5ZM9 5.5L9 12.5H7L7 5.5H9ZM3.5 5.5H5.5L5.5 12.5H4.5C3.94772 12.5 3.5 12.0523 3.5 11.5V5.5Z"})}))}function S(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 448 512",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"M448 80V128C448 172.2 347.7 208 224 208C100.3 208 0 172.2 0 128V80C0 35.82 100.3 0 224 0C347.7 0 448 35.82 448 80zM393.2 214.7C413.1 207.3 433.1 197.8 448 186.1V288C448 332.2 347.7 368 224 368C100.3 368 0 332.2 0 288V186.1C14.93 197.8 34.02 207.3 54.85 214.7C99.66 230.7 159.5 240 224 240C288.5 240 348.3 230.7 393.2 214.7V214.7zM54.85 374.7C99.66 390.7 159.5 400 224 400C288.5 400 348.3 390.7 393.2 374.7C413.1 367.3 433.1 357.8 448 346.1V432C448 476.2 347.7 512 224 512C100.3 512 0 476.2 0 432V346.1C14.93 357.8 34.02 367.3 54.85 374.7z"})}))}function y(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M0 6.75C0 6.35156 0.338542 6 0.722222 6L3.61111 6V3L0.722222 3C0.338542 3 0 2.67188 0 2.25C0 1.85156 0.338542 1.5 0.722222 1.5L3.61111 1.5V0.750001C3.61111 0.351563 3.94965 0 4.33333 0C4.73958 0 5.05556 0.351563 5.05556 0.750001H5.77778C7.53819 0.750001 8.98264 2.03906 9.32118 3.75H12V5.25H9.32118C9.29095 5.4049 9.25189 5.55606 9.20457 5.70291C9.10459 5.73587 9.00778 5.77066 8.9144 5.80723C8.505 5.96755 8.12646 6.17556 7.83841 6.44187C7.5498 6.70871 7.3 7.08678 7.3 7.56255V7.90902C6.83862 8.12843 6.32337 8.25 5.77778 8.25H5.05556C5.05556 8.67188 4.73958 9 4.33333 9C3.94965 9 3.61111 8.67188 3.61111 8.25V7.5L0.722222 7.5C0.338542 7.5 0 7.17188 0 6.75ZM16 8.5V7.5625C16 6.70312 14.1964 6 12 6C9.78571 6 8 6.70312 8 7.5625V8.5C8 9.37891 9.78571 10.0625 12 10.0625C14.1964 10.0625 16 9.37891 16 8.5ZM16 9.65234C15.7321 9.86719 15.375 10.0625 15.0179 10.1992C14.2143 10.5117 13.1429 10.6875 12 10.6875C10.8393 10.6875 9.76786 10.5117 8.96429 10.1992C8.60714 10.0625 8.25 9.86719 8 9.65234V11.625C8 12.5039 9.78571 13.1875 12 13.1875C14.1964 13.1875 16 12.5039 16 11.625V9.65234ZM12 13.8125C10.8393 13.8125 9.76786 13.6367 8.96429 13.3242C8.60714 13.1875 8.25 12.9922 8 12.7773V14.4375C8 15.3164 9.78571 16 12 16C14.1964 16 16 15.3164 16 14.4375V12.7773C15.7321 12.9922 15.375 13.1875 15.0179 13.3242C14.2143 13.6367 13.1429 13.8125 12 13.8125Z"})}))}function w(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M0 6.75C0 6.35156 0.351562 6 0.75 6L3.75 6V3L0.75 3C0.351562 3 0 2.67188 0 2.25C0 1.85156 0.351562 1.5 0.75 1.5L3.75 1.5V0.750001C3.75 0.351563 4.10156 0 4.5 0C4.92188 0 5.25 0.351563 5.25 0.750001H6C7.82812 0.750001 9.32812 2.03906 9.67969 3.75H12V5.25H9.67969C9.60376 5.62455 9.47428 5.97724 9.2995 6.30005H7.19969C6.09701 6.30005 5.26846 7.20143 5.25 8.25C5.25 8.67188 4.92188 9 4.5 9C4.10156 9 3.75 8.67188 3.75 8.25V7.5L0.75 7.5C0.351562 7.5 0 7.17188 0 6.75ZM16 8.28571C16 7.58259 15.4336 7 14.75 7H7.25C6.54688 7 6 7.58259 6 8.28571V14.7143C6 15.4375 6.54688 16 7.25 16H14.75C15.4336 16 16 15.4375 16 14.7143V8.28571ZM10.375 9.57143V11.5H7.25V9.57143H10.375ZM7.25 14.7143V12.7857H10.375V14.7143H7.25ZM14.75 14.7143H11.625V12.7857H14.75V14.7143ZM14.75 9.57143V11.5H11.625V9.57143H14.75Z"})}))}function R(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"M13.2812 4.875H8.40625L6.78125 3.25H2.71875C2.0332 3.25 1.5 3.80859 1.5 4.46875V11.7812C1.5 12.4668 2.0332 13 2.71875 13H13.2812C13.9414 13 14.5 12.4668 14.5 11.7812V6.09375C14.5 5.43359 13.9414 4.875 13.2812 4.875Z"})}))}function L(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"M15.2109 9.06445C15.4648 8.6582 15.1602 8.125 14.6777 8.125H4.54688C4.01367 8.125 3.37891 8.50586 3.125 8.9375L1.29688 12.0859C1.04297 12.4922 1.34766 13 1.83008 13H11.9609C12.4941 13 13.1289 12.6445 13.3828 12.2129L15.2109 9.06445ZM4.54688 7.3125H12.875V6.09375C12.875 5.43359 12.3164 4.875 11.6562 4.875H7.59375L5.96875 3.25H1.90625C1.2207 3.25 0.6875 3.80859 0.6875 4.46875V11.5527L2.43945 8.53125C2.87109 7.79492 3.6582 7.3125 4.54688 7.3125Z"})}))}function T(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M9.24935 2.94323L8.5 9.5H12.1L11.1446 14.2772C11.0322 14.839 11.7994 15.1177 12.0738 14.6147L15.9111 7.57956C16.1765 7.09311 15.8244 6.5 15.2703 6.5H12.9L13.5325 3.33728C13.6192 2.90413 13.2879 2.5 12.8461 2.5H9.74611C9.49194 2.5 9.27821 2.69069 9.24935 2.94323ZM7.40003 10.5L8.25717 3H1.625C0.710938 3 0 3.73633 0 4.625V12.75C0 13.6641 0.710938 14.375 1.625 14.375H10.1517C10.1538 14.2803 10.1646 14.1822 10.1848 14.0811L10.901 10.5H7.40003ZM5.6875 8.6875V6.25H1.625V8.6875H5.6875ZM1.625 10.3125V12.75H5.6875V10.3125H1.625Z"})}))}function x(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"m1.5 3.25c0-0.41421 0.33579-0.75 0.75-0.75h1.0109c0.41421 0 0.75-0.33579 0.75-0.75s-0.33579-0.75-0.75-0.75h-1.0109c-1.2426 0-2.25 1.0074-2.25 2.25v9.5c0 1.2426 1.0074 2.25 2.25 2.25h1.0109c0.41421 0 0.75-0.3358 0.75-0.75s-0.33579-0.75-0.75-0.75h-1.0109c-0.41421 0-0.75-0.3358-0.75-0.75v-9.5zm11.239-2.25c-0.4142 0-0.75 0.33579-0.75 0.75s0.3358 0.75 0.75 0.75h1.0109c0.4142 0 0.75 0.33579 0.75 0.75v9.5c0 0.4142-0.3358 0.75-0.75 0.75h-1.0109c-0.4142 0-0.75 0.3358-0.75 0.75s0.3358 0.75 0.75 0.75h1.0109c1.2426 0 2.25-1.0074 2.25-2.25v-9.5c0-1.2426-1.0074-2.25-2.25-2.25h-1.0109zm-1.4316 6.9054c-0.9374 0.45226-2.1226 0.63619-3.3102 0.63619-1.1876 0-2.3728-0.18393-3.3103-0.63619-0.21174-0.10215-0.42044-0.22399-0.61701-0.36633v0.46091c0 1.3714 1.7583 2.0571 3.9273 2.0571 2.169 0 3.9273-0.68571 3.9273-2.0571v-0.46091c-0.1966 0.14234-0.4053 0.26418-0.6171 0.36633zm-3.3102-0.59108c2.169 0 3.9273-0.68572 3.9273-2.0571 0-1.3714-1.7583-2.0572-3.9273-2.0572-2.169 0-3.9273 0.68572-3.9273 2.0572 0 1.3714 1.7583 2.0571 3.9273 2.0571zm3.9273 3.4286c0 1.3714-1.7583 2.0571-3.9273 2.0571-2.169 0-3.9273-0.6857-3.9273-2.0571v-0.461c0.19657 0.1423 0.40527 0.2641 0.61701 0.3663 0.93748 0.4522 2.1227 0.6362 3.3103 0.6362 1.1876 0 2.3728-0.184 3.3102-0.6362 0.2118-0.1022 0.4205-0.224 0.6171-0.3663v0.461z",fill:"currentColor",clipRule:"evenodd",fillRule:"evenodd"})}))}function k(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M2.01033 3.79551C2.11275 2.787 2.96447 2 4 2H7.3H8.8H12C13.1046 2 14 2.89543 14 4V5.5V8.2002V9.7002V12C14 13.1046 13.1046 14 12 14H8.8H7.3H4C2.89543 14 2 13.1046 2 12V9.7002V8.2002V5.5V4C2 3.93096 2.0035 3.86275 2.01033 3.79551ZM8.8 12.5H11.5C12.0523 12.5 12.5 12.0523 12.5 11.5V9.7002H8.8V12.5ZM7.3 9.7002V12.5H4.5C3.94772 12.5 3.5 12.0523 3.5 11.5V9.7002H7.3ZM8.8 8.2002H12.5V5.5H8.8L8.8 8.2002ZM7.3 5.5L7.3 8.2002H3.5V5.5H7.3Z"})}))}function A(e){return(0,s.jsxs)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:[(0,s.jsx)("rect",{x:"2",y:"2.20001",width:"9",height:"2.5",rx:"0.5"}),(0,s.jsx)("rect",{x:"5",y:"6.70001",width:"9",height:"2.5",rx:"0.5"}),(0,s.jsx)("rect",{x:"2",y:"11.2",width:"9",height:"2.5",rx:"0.5"})]}))}function N(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M9.22 15.03s-.001 0 0 0a.75.75 0 0 0 1.06-1.06l-.47-.47H10a3.016 3.016 0 0 0 1.507-.405A2.999 2.999 0 0 0 13 10.5V7.896h.003a2.735 2.735 0 0 0 .785-.366 2.75 2.75 0 1 0-2.288.366V10.5A1.5 1.5 0 0 1 10 12h-.19l.47-.47s0 .001 0 0a.75.75 0 0 0-1.06-1.06l-.47.47-1.28 1.28a.75.75 0 0 0 0 1.06l1.75 1.75ZM5.72 2.97a.75.75 0 0 1 1.06 0l.47.47 1.28 1.28a.748.748 0 0 1 0 1.06L6.78 7.53c.001 0 0 0 0 0a.751.751 0 0 1-1.06-1.06L6.19 6H6a1.5 1.5 0 0 0-1.5 1.5v2.604a2.757 2.757 0 0 1 2 2.646 2.738 2.738 0 0 1-1.212 2.28 2.737 2.737 0 0 1-1.538.47A2.747 2.747 0 0 1 1 12.75a2.751 2.751 0 0 1 2-2.646V7.5a2.999 2.999 0 0 1 3-3h.19l-.47-.47a.75.75 0 0 1 0-1.06Zm-.908 9.121A1.246 1.246 0 0 1 5 12.75a1.25 1.25 0 1 1-.188-.659ZM11 5.25a1.25 1.25 0 1 1 2.5 0 1.25 1.25 0 0 1-2.5 0Z"})}))}function I(e){return(0,s.jsxs)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:[(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M1.625 2H7.49951C6.47457 2.77006 5.7552 3.92488 5.55588 5.25H1.625V7.6875H5.79193C6.48417 9.6186 8.33076 11 10.5 11C10.877 11 11.2443 10.9583 11.5974 10.8792L12.7748 12.5799C12.4905 13.0601 11.9665 13.375 11.375 13.375H1.625C0.710938 13.375 0 12.6641 0 11.75V3.625C0 2.73633 0.710938 2 1.625 2ZM1.625 11.75V9.3125H5.6875V11.75H1.625Z"}),(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M13.4411 8.71106C14.0985 7.9983 14.5 7.04604 14.5 6C14.5 3.79086 12.7091 2 10.5 2C8.29086 2 6.5 3.79086 6.5 6C6.5 8.20914 8.29086 10 10.5 10C11.0316 10 11.5389 9.89631 12.0029 9.70806L14.2807 12.9981C14.5557 13.3955 15.1008 13.4946 15.4981 13.2195C15.8955 12.9444 15.9946 12.3993 15.7195 12.002L13.4411 8.71106ZM12.5 6C12.5 7.10457 11.6046 8 10.5 8C9.39543 8 8.5 7.10457 8.5 6C8.5 4.89543 9.39543 4 10.5 4C11.6046 4 12.5 4.89543 12.5 6Z"})]}))}function O(e){return"status"in e}function D(e,t,i,s=0){const n=e[t];if(n&&(i(n,s,t,e),!n.collapsed))for(const r of n.children)D(e,`${t}/${r}`,i,s+1)}var M;function P(e){return Object.assign(Object.assign(Object.assign({},{collapsed:!0,loading:!1,loaded:!1,error:!1,children:[]}),{expandable:"database"===e.type||"directory"===e.type}),e)}function F(e={},t){var i,s;switch(t.type){case M.ToggleCollapsed:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{collapsed:!e[t.payload.path].collapsed})});case M.StartLoading:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{loading:!0,loaded:!1,error:!1,children:[]})});case M.FinishLoading:{const n=Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{loading:!1,loaded:Boolean(t.payload.data),error:!1})});if(t.payload.data){n[t.payload.path].children=t.payload.data.map((({name:e})=>e));for(const r of t.payload.data){const o=`${t.payload.path}/${r.name}`,{activePath:a=""}=t.payload,c=null!==(s=null===(i=e[o])||void 0===i?void 0:i.collapsed)&&void 0!==s?s:!a.startsWith(`${o}/`);n[o]=P(Object.assign(Object.assign({},r),{collapsed:c,path:o}))}}return t.payload.data&&0!==t.payload.data.length||(n[t.payload.path]=Object.assign(Object.assign({},n[t.payload.path]),{expandable:!1,collapsed:!0})),n}case M.ErrorLoading:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{loading:!1,loaded:!1,error:!0})});case M.ResetNode:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{collapsed:!0,loading:!1,loaded:!1,error:!1,children:[]})});default:return e}}function U(e,t){const i=[];return D(e,t,((e,t)=>{i.push(Object.assign(Object.assign({},e),{level:t}));const s=function(e,t){if(!e.collapsed)return e.loading?{path:e.path,status:"loading",level:t+1}:e.error?{path:e.path,status:"error",level:t+1}:e.loaded&&0===e.children.length?{path:e.path,status:"empty",level:t+1}:void 0}(e,t);s&&i.push(s)})),i}function H(e,t){switch(e){case"async_replication":return(0,s.jsx)(E,{height:16});case"transfer":return(0,s.jsx)(N,{height:16});case"database":return(0,s.jsx)(S,{height:14});case"directory":return t?(0,s.jsx)(R,{height:16}):(0,s.jsx)(L,{height:16});case"index":return(0,s.jsx)(T,{height:16});case"table":case"index_table":return(0,s.jsx)(k,{height:16});case"column_table":return(0,s.jsx)(b,{height:16});case"stream":case"topic":return(0,s.jsx)(A,{height:16});case"external_table":return(0,s.jsx)(w,{height:16});case"external_data_source":return(0,s.jsx)(y,{height:16});case"view":return(0,s.jsx)(I,{height:16});case"resource_pool":return(0,s.jsx)(x,{height:16});default:return null}}function B({path:e,fetchPath:t,activePath:i,state:r,level:o,dispatch:a,children:l,onActivate:h,getActions:d,onActionsOpenToggle:u,renderAdditionalNodeElements:g,cache:p}){const m=r[e];n.useEffect((()=>{m.collapsed?p||a({type:M.ResetNode,payload:{path:e}}):m.loaded||m.loading||(a({type:M.StartLoading,payload:{path:e}}),t(e).then((t=>{a({type:M.FinishLoading,payload:{path:e,activePath:i,data:t}})})).catch((t=>{a({type:M.ErrorLoading,payload:{path:e,error:t}})})))}),[i,p,a,t,m.collapsed,m.loaded,m.loading,e]);const f=n.useCallback((()=>{h&&h(e)}),[e,h]),_=n.useCallback((()=>{a({type:M.ToggleCollapsed,payload:{path:e}})}),[a,e]),v=n.useMemo((()=>null===g||void 0===g?void 0:g(m.path,m.type,m.meta)),[g,m]),C=n.useMemo((()=>null===d||void 0===d?void 0:d(m.path,m.type,m.meta)),[d,m]),E=n.useCallback((e=>{null===u||void 0===u||u({path:m.path,type:m.type,isOpen:e})}),[m.path,m.type,u]);return(0,s.jsx)(c.G,{name:m.name,icon:H(m.type,m.collapsed),collapsed:m.collapsed,active:m.path===i,actions:C,additionalNodeElements:v,hasArrow:m.expandable,onClick:f,onArrowClick:_,onActionsOpenToggle:E,level:o,children:l})}!function(e){e.ToggleCollapsed="toggle-collapsed",e.StartLoading="start-loading",e.FinishLoading="finish-loading",e.ErrorLoading="error-loading",e.ResetNode="reset-node"}(M||(M={}));const W=e=>{const t=`${e.path}|${e.status}`;return"loading"===e.status?(0,s.jsx)(C,{level:e.level},t):"error"===e.status?(0,s.jsx)(f,{level:e.level},t):(0,s.jsx)(p,{level:e.level},t)};function V({rootState:e,fetchPath:t,getActions:i,renderAdditionalNodeElements:r,activePath:a,onActionsOpenToggle:c,onActivePathUpdate:l,cache:h=!0,virtualize:d=!1}){const[u,g]=n.useReducer(F,{[e.path]:P(e)}),p=n.useMemo((()=>U(u,e.path)),[e.path,u]),m=e=>(0,s.jsx)(B,{state:u,path:e.path,activePath:a,fetchPath:t,dispatch:g,onActivate:l,getActions:i,onActionsOpenToggle:c,renderAdditionalNodeElements:r,cache:h,level:e.level},e.path);return d?(0,s.jsx)(o(),{type:"uniform",length:p.length,useStaticSize:!0,itemRenderer:e=>{const t=p[e];return O(t)?W(t):m(t)}}):(0,s.jsx)(n.Fragment,{children:p.map((e=>O(e)?W(e):m(e)))})}},90208:(e,t,i)=>{"use strict";i.d(t,{L9:()=>w,LR:()=>v,ZR:()=>y});var s=i(25890),n=i(17799),r=i(8995),o=i(5662),a=i(44320),c=i(36456),l=i(89403),h=i(79400),d=i(62083),u=i(56942),g=i(78209),p=i(37227),m=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},f=function(e,t){return function(i,s){t(i,s,e)}};class _{async provideDocumentPasteEdits(e,t,i,s,n){const r=await this.getEdit(i,n);if(r)return{edits:[{insertText:r.insertText,title:r.title,kind:r.kind,handledMimeType:r.handledMimeType,yieldTo:r.yieldTo}],dispose(){}}}async provideDocumentDropEdits(e,t,i,s){const n=await this.getEdit(i,s);if(n)return{edits:[{insertText:n.insertText,title:n.title,kind:n.kind,handledMimeType:n.handledMimeType,yieldTo:n.yieldTo}],dispose(){}}}}class v extends _{constructor(){super(...arguments),this.kind=v.kind,this.dropMimeTypes=[a.K.text],this.pasteMimeTypes=[a.K.text]}static{this.id="text"}static{this.kind=new r.k("text.plain")}async getEdit(e,t){const i=e.get(a.K.text);if(!i)return;if(e.has(a.K.uriList))return;const s=await i.asString();return{handledMimeType:a.K.text,title:(0,g.kg)("text.label","Insert Plain Text"),insertText:s,kind:this.kind}}}class C extends _{constructor(){super(...arguments),this.kind=new r.k("uri.absolute"),this.dropMimeTypes=[a.K.uriList],this.pasteMimeTypes=[a.K.uriList]}async getEdit(e,t){const i=await S(e);if(!i.length||t.isCancellationRequested)return;let s=0;const n=i.map((({uri:e,originalText:t})=>e.scheme===c.ny.file?e.fsPath:(s++,t))).join(" ");let r;return r=s>0?i.length>1?(0,g.kg)("defaultDropProvider.uriList.uris","Insert Uris"):(0,g.kg)("defaultDropProvider.uriList.uri","Insert Uri"):i.length>1?(0,g.kg)("defaultDropProvider.uriList.paths","Insert Paths"):(0,g.kg)("defaultDropProvider.uriList.path","Insert Path"),{handledMimeType:a.K.uriList,insertText:n,title:r,kind:this.kind}}}let E=class extends _{constructor(e){super(),this._workspaceContextService=e,this.kind=new r.k("uri.relative"),this.dropMimeTypes=[a.K.uriList],this.pasteMimeTypes=[a.K.uriList]}async getEdit(e,t){const i=await S(e);if(!i.length||t.isCancellationRequested)return;const n=(0,s.Yc)(i.map((({uri:e})=>{const t=this._workspaceContextService.getWorkspaceFolder(e);return t?(0,l.iZ)(t.uri,e):void 0})));return n.length?{handledMimeType:a.K.uriList,insertText:n.join(" "),title:i.length>1?(0,g.kg)("defaultDropProvider.uriList.relativePaths","Insert Relative Paths"):(0,g.kg)("defaultDropProvider.uriList.relativePath","Insert Relative Path"),kind:this.kind}:void 0}};E=m([f(0,p.VR)],E);class b{constructor(){this.kind=new r.k("html"),this.pasteMimeTypes=["text/html"],this._yieldTo=[{mimeType:a.K.text}]}async provideDocumentPasteEdits(e,t,i,s,n){if(s.triggerKind!==d.FX.PasteAs&&!s.only?.contains(this.kind))return;const r=i.get("text/html"),o=await(r?.asString());return o&&!n.isCancellationRequested?{dispose(){},edits:[{insertText:o,yieldTo:this._yieldTo,title:(0,g.kg)("pasteHtmlLabel","Insert HTML"),kind:this.kind}]}:void 0}}async function S(e){const t=e.get(a.K.uriList);if(!t)return[];const i=await t.asString(),s=[];for(const r of n.jt.parse(i))try{s.push({uri:h.r.parse(r),originalText:r})}catch{}return s}let y=class extends o.jG{constructor(e,t){super(),this._register(e.documentDropEditProvider.register("*",new v)),this._register(e.documentDropEditProvider.register("*",new C)),this._register(e.documentDropEditProvider.register("*",new E(t)))}};y=m([f(0,u.ILanguageFeaturesService),f(1,p.VR)],y);let w=class extends o.jG{constructor(e,t){super(),this._register(e.documentPasteEditProvider.register("*",new v)),this._register(e.documentPasteEditProvider.register("*",new C)),this._register(e.documentPasteEditProvider.register("*",new E(t))),this._register(e.documentPasteEditProvider.register("*",new b))}};w=m([f(0,u.ILanguageFeaturesService),f(1,p.VR)],w)},90360:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ITextResourceConfigurationService:()=>n,ITextResourcePropertiesService:()=>r});var s=i(63591);const n=(0,s.u1)("textResourceConfigurationService"),r=(0,s.u1)("textResourcePropertiesService")},90474:(e,t,i)=>{"use strict";i.d(t,{Mj:()=>k});var s={grad:.9,turn:360,rad:360/(2*Math.PI)},n=function(e){return"string"==typeof e?e.length>0:"number"==typeof e},r=function(e,t,i){return void 0===t&&(t=0),void 0===i&&(i=Math.pow(10,t)),Math.round(i*e)/i+0},o=function(e,t,i){return void 0===t&&(t=0),void 0===i&&(i=1),e>i?i:e>t?e:t},a=function(e){return(e=isFinite(e)?e%360:0)>0?e:e+360},c=function(e){return{r:o(e.r,0,255),g:o(e.g,0,255),b:o(e.b,0,255),a:o(e.a)}},l=function(e){return{r:r(e.r),g:r(e.g),b:r(e.b),a:r(e.a,3)}},h=/^#([0-9a-f]{3,8})$/i,d=function(e){var t=e.toString(16);return t.length<2?"0"+t:t},u=function(e){var t=e.r,i=e.g,s=e.b,n=e.a,r=Math.max(t,i,s),o=r-Math.min(t,i,s),a=o?r===t?(i-s)/o:r===i?2+(s-t)/o:4+(t-i)/o:0;return{h:60*(a<0?a+6:a),s:r?o/r*100:0,v:r/255*100,a:n}},g=function(e){var t=e.h,i=e.s,s=e.v,n=e.a;t=t/360*6,i/=100,s/=100;var r=Math.floor(t),o=s*(1-i),a=s*(1-(t-r)*i),c=s*(1-(1-t+r)*i),l=r%6;return{r:255*[s,a,o,o,c,s][l],g:255*[c,s,s,a,o,o][l],b:255*[o,o,c,s,s,a][l],a:n}},p=function(e){return{h:a(e.h),s:o(e.s,0,100),l:o(e.l,0,100),a:o(e.a)}},m=function(e){return{h:r(e.h),s:r(e.s),l:r(e.l),a:r(e.a,3)}},f=function(e){return g((i=(t=e).s,{h:t.h,s:(i*=((s=t.l)<50?s:100-s)/100)>0?2*i/(s+i)*100:0,v:s+i,a:t.a}));var t,i,s},_=function(e){return{h:(t=u(e)).h,s:(n=(200-(i=t.s))*(s=t.v)/100)>0&&n<200?i*s/100/(n<=100?n:200-n)*100:0,l:n/2,a:t.a};var t,i,s,n},v=/^hsla?\(\s*([+-]?\d*\.?\d+)(deg|rad|grad|turn)?\s*,\s*([+-]?\d*\.?\d+)%\s*,\s*([+-]?\d*\.?\d+)%\s*(?:,\s*([+-]?\d*\.?\d+)(%)?\s*)?\)$/i,C=/^hsla?\(\s*([+-]?\d*\.?\d+)(deg|rad|grad|turn)?\s+([+-]?\d*\.?\d+)%\s+([+-]?\d*\.?\d+)%\s*(?:\/\s*([+-]?\d*\.?\d+)(%)?\s*)?\)$/i,E=/^rgba?\(\s*([+-]?\d*\.?\d+)(%)?\s*,\s*([+-]?\d*\.?\d+)(%)?\s*,\s*([+-]?\d*\.?\d+)(%)?\s*(?:,\s*([+-]?\d*\.?\d+)(%)?\s*)?\)$/i,b=/^rgba?\(\s*([+-]?\d*\.?\d+)(%)?\s+([+-]?\d*\.?\d+)(%)?\s+([+-]?\d*\.?\d+)(%)?\s*(?:\/\s*([+-]?\d*\.?\d+)(%)?\s*)?\)$/i,S={string:[[function(e){var t=h.exec(e);return t?(e=t[1]).length<=4?{r:parseInt(e[0]+e[0],16),g:parseInt(e[1]+e[1],16),b:parseInt(e[2]+e[2],16),a:4===e.length?r(parseInt(e[3]+e[3],16)/255,2):1}:6===e.length||8===e.length?{r:parseInt(e.substr(0,2),16),g:parseInt(e.substr(2,2),16),b:parseInt(e.substr(4,2),16),a:8===e.length?r(parseInt(e.substr(6,2),16)/255,2):1}:null:null},"hex"],[function(e){var t=E.exec(e)||b.exec(e);return t?t[2]!==t[4]||t[4]!==t[6]?null:c({r:Number(t[1])/(t[2]?100/255:1),g:Number(t[3])/(t[4]?100/255:1),b:Number(t[5])/(t[6]?100/255:1),a:void 0===t[7]?1:Number(t[7])/(t[8]?100:1)}):null},"rgb"],[function(e){var t=v.exec(e)||C.exec(e);if(!t)return null;var i,n,r=p({h:(i=t[1],n=t[2],void 0===n&&(n="deg"),Number(i)*(s[n]||1)),s:Number(t[3]),l:Number(t[4]),a:void 0===t[5]?1:Number(t[5])/(t[6]?100:1)});return f(r)},"hsl"]],object:[[function(e){var t=e.r,i=e.g,s=e.b,r=e.a,o=void 0===r?1:r;return n(t)&&n(i)&&n(s)?c({r:Number(t),g:Number(i),b:Number(s),a:Number(o)}):null},"rgb"],[function(e){var t=e.h,i=e.s,s=e.l,r=e.a,o=void 0===r?1:r;if(!n(t)||!n(i)||!n(s))return null;var a=p({h:Number(t),s:Number(i),l:Number(s),a:Number(o)});return f(a)},"hsl"],[function(e){var t=e.h,i=e.s,s=e.v,r=e.a,c=void 0===r?1:r;if(!n(t)||!n(i)||!n(s))return null;var l=function(e){return{h:a(e.h),s:o(e.s,0,100),v:o(e.v,0,100),a:o(e.a)}}({h:Number(t),s:Number(i),v:Number(s),a:Number(c)});return g(l)},"hsv"]]},y=function(e,t){for(var i=0;i=.5},e.prototype.toHex=function(){return t=(e=l(this.rgba)).r,i=e.g,s=e.b,o=(n=e.a)<1?d(r(255*n)):"","#"+d(t)+d(i)+d(s)+o;var e,t,i,s,n,o},e.prototype.toRgb=function(){return l(this.rgba)},e.prototype.toRgbString=function(){return t=(e=l(this.rgba)).r,i=e.g,s=e.b,(n=e.a)<1?"rgba("+t+", "+i+", "+s+", "+n+")":"rgb("+t+", "+i+", "+s+")";var e,t,i,s,n},e.prototype.toHsl=function(){return m(_(this.rgba))},e.prototype.toHslString=function(){return t=(e=m(_(this.rgba))).h,i=e.s,s=e.l,(n=e.a)<1?"hsla("+t+", "+i+"%, "+s+"%, "+n+")":"hsl("+t+", "+i+"%, "+s+"%)";var e,t,i,s,n},e.prototype.toHsv=function(){return e=u(this.rgba),{h:r(e.h),s:r(e.s),v:r(e.v),a:r(e.a,3)};var e},e.prototype.invert=function(){return k({r:255-(e=this.rgba).r,g:255-e.g,b:255-e.b,a:e.a});var e},e.prototype.saturate=function(e){return void 0===e&&(e=.1),k(R(this.rgba,e))},e.prototype.desaturate=function(e){return void 0===e&&(e=.1),k(R(this.rgba,-e))},e.prototype.grayscale=function(){return k(R(this.rgba,-1))},e.prototype.lighten=function(e){return void 0===e&&(e=.1),k(T(this.rgba,e))},e.prototype.darken=function(e){return void 0===e&&(e=.1),k(T(this.rgba,-e))},e.prototype.rotate=function(e){return void 0===e&&(e=15),this.hue(this.hue()+e)},e.prototype.alpha=function(e){return"number"==typeof e?k({r:(t=this.rgba).r,g:t.g,b:t.b,a:e}):r(this.rgba.a,3);var t},e.prototype.hue=function(e){var t=_(this.rgba);return"number"==typeof e?k({h:e,s:t.s,l:t.l,a:t.a}):r(t.h)},e.prototype.isEqual=function(e){return this.toHex()===k(e).toHex()},e}(),k=function(e){return e instanceof x?e:new x(e)}},90651:(e,t,i)=>{"use strict";i.d(t,{k:()=>s});const s=(0,i(63591).u1)("telemetryService")},90766:(e,t,i)=>{"use strict";i.d(t,{$1:()=>_,$6:()=>b,A0:()=>y,AE:()=>T,EQ:()=>f,F6:()=>w,HC:()=>L,PK:()=>d,Qg:()=>l,SS:()=>h,Th:()=>p,Zv:()=>R,b7:()=>S,bI:()=>k,pc:()=>v,uC:()=>E,vb:()=>C,ve:()=>g,wR:()=>m});var s=i(18447),n=i(64383),r=i(41234),o=i(5662),a=i(98067),c=i(44759);function l(e){return!!e&&"function"===typeof e.then}function h(e){const t=new s.Qi,i=e(t.token),r=new Promise(((e,s)=>{const r=t.token.onCancellationRequested((()=>{r.dispose(),s(new n.AL)}));Promise.resolve(i).then((i=>{r.dispose(),t.dispose(),e(i)}),(e=>{r.dispose(),t.dispose(),s(e)}))}));return new class{cancel(){t.cancel(),t.dispose()}then(e,t){return r.then(e,t)}catch(e){return this.then(void 0,e)}finally(e){return r.finally(e)}}}function d(e,t,i){return new Promise(((s,n)=>{const r=t.onCancellationRequested((()=>{r.dispose(),s(i)}));e.then(s,n).finally((()=>r.dispose()))}))}class u{constructor(){this.isDisposed=!1,this.activePromise=null,this.queuedPromise=null,this.queuedPromiseFactory=null}queue(e){if(this.isDisposed)return Promise.reject(new Error("Throttler is disposed"));if(this.activePromise){if(this.queuedPromiseFactory=e,!this.queuedPromise){const e=()=>{if(this.queuedPromise=null,this.isDisposed)return;const e=this.queue(this.queuedPromiseFactory);return this.queuedPromiseFactory=null,e};this.queuedPromise=new Promise((t=>{this.activePromise.then(e,e).then(t)}))}return new Promise(((e,t)=>{this.queuedPromise.then(e,t)}))}return this.activePromise=e(),new Promise(((e,t)=>{this.activePromise.then((t=>{this.activePromise=null,e(t)}),(e=>{this.activePromise=null,t(e)}))}))}dispose(){this.isDisposed=!0}}class g{constructor(e){this.defaultDelay=e,this.deferred=null,this.completionPromise=null,this.doResolve=null,this.doReject=null,this.task=null}trigger(e,t=this.defaultDelay){this.task=e,this.cancelTimeout(),this.completionPromise||(this.completionPromise=new Promise(((e,t)=>{this.doResolve=e,this.doReject=t})).then((()=>{if(this.completionPromise=null,this.doResolve=null,this.task){const e=this.task;return this.task=null,e()}})));const i=()=>{this.deferred=null,this.doResolve?.(null)};return this.deferred=t===c.h?(e=>{let t=!0;return queueMicrotask((()=>{t&&(t=!1,e())})),{isTriggered:()=>t,dispose:()=>{t=!1}}})(i):((e,t)=>{let i=!0;const s=setTimeout((()=>{i=!1,t()}),e);return{isTriggered:()=>i,dispose:()=>{clearTimeout(s),i=!1}}})(t,i),this.completionPromise}isTriggered(){return!!this.deferred?.isTriggered()}cancel(){this.cancelTimeout(),this.completionPromise&&(this.doReject?.(new n.AL),this.completionPromise=null)}cancelTimeout(){this.deferred?.dispose(),this.deferred=null}dispose(){this.cancel()}}class p{constructor(e){this.delayer=new g(e),this.throttler=new u}trigger(e,t){return this.delayer.trigger((()=>this.throttler.queue(e)),t)}cancel(){this.delayer.cancel()}dispose(){this.delayer.dispose(),this.throttler.dispose()}}function m(e,t){return t?new Promise(((i,s)=>{const r=setTimeout((()=>{o.dispose(),i()}),e),o=t.onCancellationRequested((()=>{clearTimeout(r),o.dispose(),s(new n.AL)}))})):h((t=>m(e,t)))}function f(e,t=0,i){const s=setTimeout((()=>{e(),i&&n.dispose()}),t),n=(0,o.s)((()=>{clearTimeout(s),i?.deleteAndLeak(n)}));return i?.add(n),n}function _(e,t=e=>!!e,i=null){let s=0;const n=e.length,r=()=>{if(s>=n)return Promise.resolve(i);const o=e[s++];return Promise.resolve(o()).then((e=>t(e)?Promise.resolve(e):r()))};return r()}class v{constructor(e,t){this._isDisposed=!1,this._token=-1,"function"===typeof e&&"number"===typeof t&&this.setIfNotSet(e,t)}dispose(){this.cancel(),this._isDisposed=!0}cancel(){-1!==this._token&&(clearTimeout(this._token),this._token=-1)}cancelAndSet(e,t){if(this._isDisposed)throw new n.D7("Calling 'cancelAndSet' on a disposed TimeoutTimer");this.cancel(),this._token=setTimeout((()=>{this._token=-1,e()}),t)}setIfNotSet(e,t){if(this._isDisposed)throw new n.D7("Calling 'setIfNotSet' on a disposed TimeoutTimer");-1===this._token&&(this._token=setTimeout((()=>{this._token=-1,e()}),t))}}class C{constructor(){this.disposable=void 0,this.isDisposed=!1}cancel(){this.disposable?.dispose(),this.disposable=void 0}cancelAndSet(e,t,i=globalThis){if(this.isDisposed)throw new n.D7("Calling 'cancelAndSet' on a disposed IntervalTimer");this.cancel();const s=i.setInterval((()=>{e()}),t);this.disposable=(0,o.s)((()=>{i.clearInterval(s),this.disposable=void 0}))}dispose(){this.cancel(),this.isDisposed=!0}}class E{constructor(e,t){this.timeoutToken=-1,this.runner=e,this.timeout=t,this.timeoutHandler=this.onTimeout.bind(this)}dispose(){this.cancel(),this.runner=null}cancel(){this.isScheduled()&&(clearTimeout(this.timeoutToken),this.timeoutToken=-1)}schedule(e=this.timeout){this.cancel(),this.timeoutToken=setTimeout(this.timeoutHandler,e)}get delay(){return this.timeout}set delay(e){this.timeout=e}isScheduled(){return-1!==this.timeoutToken}onTimeout(){this.timeoutToken=-1,this.runner&&this.doRun()}doRun(){this.runner?.()}}let b,S;S="function"!==typeof globalThis.requestIdleCallback||"function"!==typeof globalThis.cancelIdleCallback?(e,t)=>{(0,a._p)((()=>{if(i)return;const e=Date.now()+15,s={didTimeout:!0,timeRemaining:()=>Math.max(0,e-Date.now())};t(Object.freeze(s))}));let i=!1;return{dispose(){i||(i=!0)}}}:(e,t,i)=>{const s=e.requestIdleCallback(t,"number"===typeof i?{timeout:i}:void 0);let n=!1;return{dispose(){n||(n=!0,e.cancelIdleCallback(s))}}},b=e=>S(globalThis,e);class y{constructor(e,t){this._didRun=!1,this._executor=()=>{try{this._value=t()}catch(e){this._error=e}finally{this._didRun=!0}},this._handle=S(e,(()=>this._executor()))}dispose(){this._handle.dispose()}get value(){if(this._didRun||(this._handle.dispose(),this._executor()),this._error)throw this._error;return this._value}get isInitialized(){return this._didRun}}class w extends y{constructor(e){super(globalThis,e)}}class R{get isRejected(){return 1===this.outcome?.outcome}get isSettled(){return!!this.outcome}constructor(){this.p=new Promise(((e,t)=>{this.completeCallback=e,this.errorCallback=t}))}complete(e){return new Promise((t=>{this.completeCallback(e),this.outcome={outcome:0,value:e},t()}))}error(e){return new Promise((t=>{this.errorCallback(e),this.outcome={outcome:1,value:e},t()}))}cancel(){return this.error(new n.AL)}}var L;!function(e){e.settled=async function(e){let t;const i=await Promise.all(e.map((e=>e.then((e=>e),(e=>{t||(t=e)})))));if("undefined"!==typeof t)throw t;return i},e.withAsyncBody=function(e){return new Promise((async(t,i)=>{try{await e(t,i)}catch(s){i(s)}}))}}(L||(L={}));class T{static fromArray(e){return new T((t=>{t.emitMany(e)}))}static fromPromise(e){return new T((async t=>{t.emitMany(await e)}))}static fromPromises(e){return new T((async t=>{await Promise.all(e.map((async e=>t.emitOne(await e))))}))}static merge(e){return new T((async t=>{await Promise.all(e.map((async e=>{for await(const i of e)t.emitOne(i)})))}))}static{this.EMPTY=T.fromArray([])}constructor(e,t){this._state=0,this._results=[],this._error=null,this._onReturn=t,this._onStateChanged=new r.vl,queueMicrotask((async()=>{const t={emitOne:e=>this.emitOne(e),emitMany:e=>this.emitMany(e),reject:e=>this.reject(e)};try{await Promise.resolve(e(t)),this.resolve()}catch(i){this.reject(i)}finally{t.emitOne=void 0,t.emitMany=void 0,t.reject=void 0}}))}[Symbol.asyncIterator](){let e=0;return{next:async()=>{for(;;){if(2===this._state)throw this._error;if(e(this._onReturn?.(),{done:!0,value:void 0})}}static map(e,t){return new T((async i=>{for await(const s of e)i.emitOne(t(s))}))}map(e){return T.map(this,e)}static filter(e,t){return new T((async i=>{for await(const s of e)t(s)&&i.emitOne(s)}))}filter(e){return T.filter(this,e)}static coalesce(e){return T.filter(e,(e=>!!e))}coalesce(){return T.coalesce(this)}static async toPromise(e){const t=[];for await(const i of e)t.push(i);return t}toPromise(){return T.toPromise(this)}emitOne(e){0===this._state&&(this._results.push(e),this._onStateChanged.fire())}emitMany(e){0===this._state&&(this._results=this._results.concat(e),this._onStateChanged.fire())}resolve(){0===this._state&&(this._state=1,this._onStateChanged.fire())}reject(e){0===this._state&&(this._state=2,this._error=e,this._onStateChanged.fire())}}class x extends T{constructor(e,t){super(t),this._source=e}cancel(){this._source.cancel()}}function k(e){const t=new s.Qi,i=e(t.token);return new x(t,(async e=>{const s=t.token.onCancellationRequested((()=>{s.dispose(),t.dispose(),e.reject(new n.AL)}));try{for await(const s of i){if(t.token.isCancellationRequested)return;e.emitOne(s)}s.dispose(),t.dispose()}catch(r){s.dispose(),t.dispose(),e.reject(r)}}))}},90851:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("g",{clipPath:"url(#a)"},s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M1.522 10.68a2.14 2.14 0 0 0 2.11 1.82 2.125 2.125 0 1 0-2.11-1.82M3.64 14h-.015a3.626 3.626 0 0 1-3.558-2.927 3.6 3.6 0 0 1 .256-2.212L2.98 2.98a2.516 2.516 0 0 1 4.802 1.237L7.673 5.6a1.5 1.5 0 0 1 .655 0l-.11-1.382a2.516 2.516 0 0 1 4.801-1.237l2.658 5.88a3.6 3.6 0 0 1 .256 2.213A3.626 3.626 0 0 1 12.375 14h-.015a3.64 3.64 0 0 1-3.628-3.35l-.174-2.176A.96.96 0 0 0 8 8.312a.96.96 0 0 0-.558.162l-.174 2.176A3.64 3.64 0 0 1 3.64 14m-.015-7.25c.91 0 1.742.336 2.379.89l.283-3.542a1.016 1.016 0 0 0-1.94-.5L2.89 6.825a3.6 3.6 0 0 1 .736-.075m10.853 3.93q.022-.15.022-.305a2.125 2.125 0 1 0-2.132 2.125 2.14 2.14 0 0 0 2.11-1.82m-2.826-7.082 1.459 3.227a3.61 3.61 0 0 0-3.115.815l-.283-3.542a1.016 1.016 0 0 1 1.94-.5",clipRule:"evenodd"})),s.createElement("defs",null,s.createElement("clipPath",{id:"a"},s.createElement("path",{fill:"currentColor",d:"M0 0h16v16H0z"}))))},90870:(e,t,i)=>{"use strict";i.d(t,{D:()=>je});var s,n=i(11007),r=i(25890),o=i(18447),a=i(64383),c=i(41234),l=i(42539),h=i(5662),d=i(98067),u=i(78381),g=i(631),p=i(55190),m=i(31450),f=i(7085),_=i(83069),v=i(36677),C=i(60002),E=i(30936),b=i(29319),S=i(88415),y=i(32848),w=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},R=function(e,t){return function(i,s){t(i,s,e)}};let L=class{static{s=this}static{this.AtEnd=new y.N1("atEndOfWord",!1)}constructor(e,t){this._editor=e,this._enabled=!1,this._ckAtEnd=s.AtEnd.bindTo(t),this._configListener=this._editor.onDidChangeConfiguration((e=>e.hasChanged(124)&&this._update())),this._update()}dispose(){this._configListener.dispose(),this._selectionListener?.dispose(),this._ckAtEnd.reset()}_update(){const e="on"===this._editor.getOption(124);if(this._enabled!==e)if(this._enabled=e,this._enabled){const e=()=>{if(!this._editor.hasModel())return void this._ckAtEnd.set(!1);const e=this._editor.getModel(),t=this._editor.getSelection(),i=e.getWordAtPosition(t.getStartPosition());i?this._ckAtEnd.set(i.endColumn===t.getStartPosition().column):this._ckAtEnd.set(!1)};this._selectionListener=this._editor.onDidChangeCursorSelection(e),e()}else this._selectionListener&&(this._ckAtEnd.reset(),this._selectionListener.dispose(),this._selectionListener=void 0)}};L=s=w([R(1,y.fN)],L);var T,x=i(78209),k=i(50091),A=i(63591),N=i(18801),I=i(48116),O=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},D=function(e,t){return function(i,s){t(i,s,e)}};let M=class{static{T=this}static{this.OtherSuggestions=new y.N1("hasOtherSuggestions",!1)}constructor(e,t){this._editor=e,this._index=0,this._ckOtherSuggestions=T.OtherSuggestions.bindTo(t)}dispose(){this.reset()}reset(){this._ckOtherSuggestions.reset(),this._listener?.dispose(),this._model=void 0,this._acceptNext=void 0,this._ignore=!1}set({model:e,index:t},i){if(0===e.items.length)return void this.reset();T._moveIndex(!0,e,t)!==t?(this._acceptNext=i,this._model=e,this._index=t,this._listener=this._editor.onDidChangeCursorPosition((()=>{this._ignore||this.reset()})),this._ckOtherSuggestions.set(!0)):this.reset()}static _moveIndex(e,t,i){let s=i;for(let n=t.items.length;n>0&&(s=(s+t.items.length+(e?1:-1))%t.items.length,s!==i)&&t.items[s].completion.additionalTextEdits;n--);return s}next(){this._move(!0)}prev(){this._move(!1)}_move(e){if(this._model)try{this._ignore=!0,this._index=T._moveIndex(e,this._model,this._index),this._acceptNext({index:this._index,item:this._model.items[this._index],model:this._model})}finally{this._ignore=!1}}};M=T=O([D(1,y.fN)],M);var P=i(60534);class F{constructor(e,t,i,s){this._disposables=new h.Cm,this._disposables.add(i.onDidSuggest((e=>{0===e.completionModel.items.length&&this.reset()}))),this._disposables.add(i.onDidCancel((e=>{this.reset()}))),this._disposables.add(t.onDidShow((()=>this._onItem(t.getFocusedItem())))),this._disposables.add(t.onDidFocus(this._onItem,this)),this._disposables.add(t.onDidHide(this.reset,this)),this._disposables.add(e.onWillType((n=>{if(this._active&&!t.isFrozen()&&0!==i.state){const t=n.charCodeAt(n.length-1);this._active.acceptCharacters.has(t)&&e.getOption(0)&&s(this._active.item)}})))}_onItem(e){if(!e||!(0,r.EI)(e.item.completion.commitCharacters))return void this.reset();if(this._active&&this._active.item.item===e.item)return;const t=new P.y;for(const i of e.item.completion.commitCharacters)i.length>0&&t.add(i.charCodeAt(0));this._active={acceptCharacters:t,item:e}}reset(){this._active=void 0}dispose(){this._disposables.dispose()}}var U=i(96299);class H{static{this._maxSelectionLength=51200}constructor(e,t){this._disposables=new h.Cm,this._lastOvertyped=[],this._locked=!1,this._disposables.add(e.onWillType((()=>{if(this._locked||!e.hasModel())return;const t=e.getSelections(),i=t.length;let s=!1;for(let e=0;eH._maxSelectionLength)return;this._lastOvertyped[e]={value:n.getValueInRange(i),multiline:i.startLineNumber!==i.endLineNumber}}}))),this._disposables.add(t.onDidTrigger((e=>{this._locked=!0}))),this._disposables.add(t.onDidCancel((e=>{this._locked=!1})))}getLastOvertypedInfo(e){if(e>=0&&e=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Q=function(e,t){return function(i,s){t(i,s,e)}};let X=class{constructor(e,t,i,s,n){this._menuId=t,this._menuService=s,this._contextKeyService=n,this._menuDisposables=new h.Cm,this.element=B.BC(e,B.$(".suggest-status-bar"));const r=e=>e instanceof q.Xe?i.createInstance(Y.rr,e,{useComma:!0}):void 0;this._leftActions=new K.E(this.element,{actionViewItemProvider:r}),this._rightActions=new K.E(this.element,{actionViewItemProvider:r}),this._leftActions.domNode.classList.add("left"),this._rightActions.domNode.classList.add("right")}dispose(){this._menuDisposables.dispose(),this._leftActions.dispose(),this._rightActions.dispose(),this.element.remove()}show(){const e=this._menuService.createMenu(this._menuId,this._contextKeyService),t=()=>{const t=[],i=[];for(const[s,n]of e.getActions())"left"===s?t.push(...n):i.push(...n);this._leftActions.clear(),this._leftActions.push(t),this._rightActions.clear(),this._rightActions.push(i)};this._menuDisposables.add(e.onDidChange((()=>t()))),this._menuDisposables.add(e)}hide(){this._menuDisposables.clear()}};X=$([Q(2,A._Y),Q(3,q.ez),Q(4,y.fN)],X);i(93409);var Z=i(9711),J=i(66261),ee=i(86723),te=i(47612),ie=i(88807),se=i(31295),ne=i(10350),re=i(25689),oe=i(16980),ae=i(20492),ce=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},le=function(e,t){return function(i,s){t(i,s,e)}};function he(e){return!!e&&Boolean(e.completion.documentation||e.completion.detail&&e.completion.detail!==e.completion.label)}let de=class{constructor(e,t){this._editor=e,this._onDidClose=new c.vl,this.onDidClose=this._onDidClose.event,this._onDidChangeContents=new c.vl,this.onDidChangeContents=this._onDidChangeContents.event,this._disposables=new h.Cm,this._renderDisposeable=new h.Cm,this._borderWidth=1,this._size=new B.fg(330,0),this.domNode=B.$(".suggest-details"),this.domNode.classList.add("no-docs"),this._markdownRenderer=t.createInstance(ae.T,{editor:e}),this._body=B.$(".body"),this._scrollbar=new se.MU(this._body,{alwaysConsumeMouseWheel:!0}),B.BC(this.domNode,this._scrollbar.getDomNode()),this._disposables.add(this._scrollbar),this._header=B.BC(this._body,B.$(".header")),this._close=B.BC(this._header,B.$("span"+re.L.asCSSSelector(ne.W.close))),this._close.title=x.kg("details.close","Close"),this._type=B.BC(this._header,B.$("p.type")),this._docs=B.BC(this._body,B.$("p.docs")),this._configureFont(),this._disposables.add(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(50)&&this._configureFont()})))}dispose(){this._disposables.dispose(),this._renderDisposeable.dispose()}_configureFont(){const e=this._editor.getOptions(),t=e.get(50),i=t.getMassagedFontFamily(),s=e.get(120)||t.fontSize,n=e.get(121)||t.lineHeight,r=t.fontWeight,o=`${s}px`,a=`${n}px`;this.domNode.style.fontSize=o,this.domNode.style.lineHeight=""+n/s,this.domNode.style.fontWeight=r,this.domNode.style.fontFeatureSettings=t.fontFeatureSettings,this._type.style.fontFamily=i,this._close.style.height=a,this._close.style.width=a}getLayoutInfo(){const e=this._editor.getOption(121)||this._editor.getOption(50).lineHeight,t=this._borderWidth;return{lineHeight:e,borderWidth:t,borderHeight:2*t,verticalPadding:22,horizontalPadding:14}}renderLoading(){this._type.textContent=x.kg("loading","Loading..."),this._docs.textContent="",this.domNode.classList.remove("no-docs","no-type"),this.layout(this.size.width,2*this.getLayoutInfo().lineHeight),this._onDidChangeContents.fire(this)}renderItem(e,t){this._renderDisposeable.clear();let{detail:i,documentation:s}=e.completion;if(t){let t="";t+=`score: ${e.score[0]}\n`,t+=`prefix: ${e.word??"(no prefix)"}\n`,t+=`word: ${e.completion.filterText?e.completion.filterText+" (filterText)":e.textLabel}\n`,t+=`distance: ${e.distance} (localityBonus-setting)\n`,t+=`index: ${e.idx}, based on ${e.completion.sortText&&`sortText: "${e.completion.sortText}"`||"label"}\n`,t+=`commit_chars: ${e.completion.commitCharacters?.join("")}\n`,s=(new oe.Bc).appendCodeblock("empty",t),i=`Provider: ${e.provider._debugDisplayName}`}if(t||he(e)){if(this.domNode.classList.remove("no-docs","no-type"),i){const e=i.length>1e5?`${i.substr(0,1e5)}\u2026`:i;this._type.textContent=e,this._type.title=e,B.WU(this._type),this._type.classList.toggle("auto-wrap",!/\r?\n^\s+/gim.test(e))}else B.w_(this._type),this._type.title="",B.jD(this._type),this.domNode.classList.add("no-type");if(B.w_(this._docs),"string"===typeof s)this._docs.classList.remove("markdown-docs"),this._docs.textContent=s;else if(s){this._docs.classList.add("markdown-docs"),B.w_(this._docs);const e=this._markdownRenderer.render(s);this._docs.appendChild(e.element),this._renderDisposeable.add(e),this._renderDisposeable.add(this._markdownRenderer.onDidRenderAsync((()=>{this.layout(this._size.width,this._type.clientHeight+this._docs.clientHeight),this._onDidChangeContents.fire(this)})))}this.domNode.style.userSelect="text",this.domNode.tabIndex=-1,this._close.onmousedown=e=>{e.preventDefault(),e.stopPropagation()},this._close.onclick=e=>{e.preventDefault(),e.stopPropagation(),this._onDidClose.fire()},this._body.scrollTop=0,this.layout(this._size.width,this._type.clientHeight+this._docs.clientHeight),this._onDidChangeContents.fire(this)}else this.clearContents()}clearContents(){this.domNode.classList.add("no-docs"),this._type.textContent="",this._docs.textContent=""}get isEmpty(){return this.domNode.classList.contains("no-docs")}get size(){return this._size}layout(e,t){const i=new B.fg(e,t);B.fg.equals(i,this._size)||(this._size=i,B.Ej(this.domNode,e,t)),this._scrollbar.scanDomNode()}scrollDown(e=8){this._body.scrollTop+=e}scrollUp(e=8){this._body.scrollTop-=e}scrollTop(){this._body.scrollTop=0}scrollBottom(){this._body.scrollTop=this._body.scrollHeight}pageDown(){this.scrollDown(80)}pageUp(){this.scrollUp(80)}set borderWidth(e){this._borderWidth=e}get borderWidth(){return this._borderWidth}};de=ce([le(1,A._Y)],de);class ue{constructor(e,t){let i,s;this.widget=e,this._editor=t,this.allowEditorOverflow=!0,this._disposables=new h.Cm,this._added=!1,this._preferAlignAtTop=!0,this._resizable=new ie.v,this._resizable.domNode.classList.add("suggest-details-container"),this._resizable.domNode.appendChild(e.domNode),this._resizable.enableSashes(!1,!0,!0,!1);let n=0,r=0;this._disposables.add(this._resizable.onDidWillResize((()=>{i=this._topLeft,s=this._resizable.size}))),this._disposables.add(this._resizable.onDidResize((e=>{if(i&&s){this.widget.layout(e.dimension.width,e.dimension.height);let t=!1;e.west&&(r=s.width-e.dimension.width,t=!0),e.north&&(n=s.height-e.dimension.height,t=!0),t&&this._applyTopLeft({top:i.top+n,left:i.left+r})}e.done&&(i=void 0,s=void 0,n=0,r=0,this._userSize=e.dimension)}))),this._disposables.add(this.widget.onDidChangeContents((()=>{this._anchorBox&&this._placeAtAnchor(this._anchorBox,this._userSize??this.widget.size,this._preferAlignAtTop)})))}dispose(){this._resizable.dispose(),this._disposables.dispose(),this.hide()}getId(){return"suggest.details"}getDomNode(){return this._resizable.domNode}getPosition(){return this._topLeft?{preference:this._topLeft}:null}show(){this._added||(this._editor.addOverlayWidget(this),this._added=!0)}hide(e=!1){this._resizable.clearSashHoverState(),this._added&&(this._editor.removeOverlayWidget(this),this._added=!1,this._anchorBox=void 0,this._topLeft=void 0),e&&(this._userSize=void 0,this.widget.clearContents())}placeAtAnchor(e,t){const i=e.getBoundingClientRect();this._anchorBox=i,this._preferAlignAtTop=t,this._placeAtAnchor(this._anchorBox,this._userSize??this.widget.size,t)}_placeAtAnchor(e,t,i){const s=B.tG(this.getDomNode().ownerDocument.body),n=this.widget.getLayoutInfo(),r=new B.fg(220,2*n.lineHeight),o=e.top,a=function(){const i=s.width-(e.left+e.width+n.borderWidth+n.horizontalPadding),a=-n.borderWidth+e.left+e.width,c=new B.fg(i,s.height-e.top-n.borderHeight-n.verticalPadding),l=c.with(void 0,e.top+e.height-n.borderHeight-n.verticalPadding);return{top:o,left:a,fit:i-t.width,maxSizeTop:c,maxSizeBottom:l,minSize:r.with(Math.min(i,r.width))}}(),c=function(){const i=e.left-n.borderWidth-n.horizontalPadding,a=Math.max(n.horizontalPadding,e.left-t.width-n.borderWidth),c=new B.fg(i,s.height-e.top-n.borderHeight-n.verticalPadding),l=c.with(void 0,e.top+e.height-n.borderHeight-n.verticalPadding);return{top:o,left:a,fit:i-t.width,maxSizeTop:c,maxSizeBottom:l,minSize:r.with(Math.min(i,r.width))}}(),l=function(){const i=e.left,o=-n.borderWidth+e.top+e.height,a=new B.fg(e.width-n.borderHeight,s.height-e.top-e.height-n.verticalPadding);return{top:o,left:i,fit:a.height-t.height,maxSizeBottom:a,maxSizeTop:a,minSize:r.with(a.width)}}(),h=[a,c,l],d=h.find((e=>e.fit>=0))??h.sort(((e,t)=>t.fit-e.fit))[0],u=e.top+e.height-n.borderHeight;let g,p=t.height;const m=Math.max(d.maxSizeTop.height,d.maxSizeBottom.height);let f;p>m&&(p=m),i?p<=d.maxSizeTop.height?(g=!0,f=d.maxSizeTop):(g=!1,f=d.maxSizeBottom):p<=d.maxSizeBottom.height?(g=!1,f=d.maxSizeBottom):(g=!0,f=d.maxSizeTop);let{top:_,left:v}=d;!g&&p>e.height&&(_=u-p);const C=this._editor.getDomNode();if(C){const e=C.getBoundingClientRect();_-=e.top,v-=e.left}this._applyTopLeft({left:v,top:_}),this._resizable.enableSashes(!g,d===a,g,d!==a),this._resizable.minSize=d.minSize,this._resizable.maxSize=f,this._resizable.layout(p,Math.min(f.width,t.width)),this.widget.layout(this._resizable.size.width,this._resizable.size.height)}_applyTopLeft(e){this._topLeft=e,this._editor.layoutOverlayWidget(this)}}var ge=i(21852),pe=i(26690),me=i(79400),fe=i(62083),_e=i(53068),ve=i(23750),Ce=i(10154),Ee=i(7291),be=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Se=function(e,t){return function(i,s){t(i,s,e)}};function ye(e){return`suggest-aria-id:${e}`}const we=(0,i(61394).pU)("suggest-more-info",ne.W.chevronRight,x.kg("suggestMoreInfoIcon","Icon for more information in the suggest widget.")),Re=new class e{static{this._regexRelaxed=/(#([\da-fA-F]{3}){1,2}|(rgb|hsl)a\(\s*(\d{1,3}%?\s*,\s*){3}(1|0?\.\d+)\)|(rgb|hsl)\(\s*\d{1,3}%?(\s*,\s*\d{1,3}%?){2}\s*\))/}static{this._regexStrict=new RegExp(`^${e._regexRelaxed.source}$`,"i")}extract(t,i){if(t.textLabel.match(e._regexStrict))return i[0]=t.textLabel,!0;if(t.completion.detail&&t.completion.detail.match(e._regexStrict))return i[0]=t.completion.detail,!0;if(t.completion.documentation){const s="string"===typeof t.completion.documentation?t.completion.documentation:t.completion.documentation.value,n=e._regexRelaxed.exec(s);if(n&&(0===n.index||n.index+n[0].length===s.length))return i[0]=n[0],!0}return!1}};let Le=class{constructor(e,t,i,s){this._editor=e,this._modelService=t,this._languageService=i,this._themeService=s,this._onDidToggleDetails=new c.vl,this.onDidToggleDetails=this._onDidToggleDetails.event,this.templateId="suggestion"}dispose(){this._onDidToggleDetails.dispose()}renderTemplate(e){const t=new h.Cm,i=e;i.classList.add("show-file-icons");const s=(0,B.BC)(e,(0,B.$)(".icon")),n=(0,B.BC)(s,(0,B.$)("span.colorspan")),r=(0,B.BC)(e,(0,B.$)(".contents")),o=(0,B.BC)(r,(0,B.$)(".main")),a=(0,B.BC)(o,(0,B.$)(".icon-label.codicon")),c=(0,B.BC)(o,(0,B.$)("span.left")),l=(0,B.BC)(o,(0,B.$)("span.right")),d=new ge.s(c,{supportHighlights:!0,supportIcons:!0});t.add(d);const u=(0,B.BC)(c,(0,B.$)("span.signature-label")),g=(0,B.BC)(c,(0,B.$)("span.qualifier-label")),p=(0,B.BC)(l,(0,B.$)("span.details-label")),m=(0,B.BC)(l,(0,B.$)("span.readMore"+re.L.asCSSSelector(we)));m.title=x.kg("readMore","Read More");return{root:i,left:c,right:l,icon:s,colorspan:n,iconLabel:d,iconContainer:a,parametersLabel:u,qualifierLabel:g,detailsLabel:p,readMore:m,disposables:t,configureFont:()=>{const e=this._editor.getOptions(),t=e.get(50),n=t.getMassagedFontFamily(),r=t.fontFeatureSettings,a=e.get(120)||t.fontSize,c=e.get(121)||t.lineHeight,l=t.fontWeight,h=`${a}px`,d=`${c}px`,u=`${t.letterSpacing}px`;i.style.fontSize=h,i.style.fontWeight=l,i.style.letterSpacing=u,o.style.fontFamily=n,o.style.fontFeatureSettings=r,o.style.lineHeight=d,s.style.height=d,s.style.width=d,m.style.height=d,m.style.width=d}}}renderElement(e,t,i){i.configureFont();const{completion:s}=e;i.root.id=ye(t),i.colorspan.style.backgroundColor="";const n={labelEscapeNewLines:!0,matches:(0,pe.WJ)(e.score)},r=[];if(19===s.kind&&Re.extract(e,r))i.icon.className="icon customcolor",i.iconContainer.className="icon hide",i.colorspan.style.backgroundColor=r[0];else if(20===s.kind&&this._themeService.getFileIconTheme().hasFileIcons){i.icon.className="icon hide",i.iconContainer.className="icon hide";const t=(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:e.textLabel}),Ee.p.FILE),r=(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:s.detail}),Ee.p.FILE);n.extraClasses=t.length>r.length?t:r}else 23===s.kind&&this._themeService.getFileIconTheme().hasFolderIcons?(i.icon.className="icon hide",i.iconContainer.className="icon hide",n.extraClasses=[(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:e.textLabel}),Ee.p.FOLDER),(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:s.detail}),Ee.p.FOLDER)].flat()):(i.icon.className="icon hide",i.iconContainer.className="",i.iconContainer.classList.add("suggest-icon",...re.L.asClassNameArray(fe.HC.toIcon(s.kind))));s.tags&&s.tags.indexOf(1)>=0&&(n.extraClasses=(n.extraClasses||[]).concat(["deprecated"]),n.matches=[]),i.iconLabel.setLabel(e.textLabel,void 0,n),"string"===typeof s.label?(i.parametersLabel.textContent="",i.detailsLabel.textContent=Te(s.detail||""),i.root.classList.add("string-label")):(i.parametersLabel.textContent=Te(s.label.detail||""),i.detailsLabel.textContent=Te(s.label.description||""),i.root.classList.remove("string-label")),this._editor.getOption(119).showInlineDetails?(0,B.WU)(i.detailsLabel):(0,B.jD)(i.detailsLabel),he(e)?(i.right.classList.add("can-expand-details"),(0,B.WU)(i.readMore),i.readMore.onmousedown=e=>{e.stopPropagation(),e.preventDefault()},i.readMore.onclick=e=>{e.stopPropagation(),e.preventDefault(),this._onDidToggleDetails.fire()}):(i.right.classList.remove("can-expand-details"),(0,B.jD)(i.readMore),i.readMore.onmousedown=null,i.readMore.onclick=null)}disposeTemplate(e){e.disposables.dispose()}};function Te(e){return e.replace(/\r\n|\r|\n/g,"")}Le=be([Se(1,ve.IModelService),Se(2,Ce.L),Se(3,te.Gy)],Le);var xe,ke=i(19070),Ae=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ne=function(e,t){return function(i,s){t(i,s,e)}};(0,J.x1A)("editorSuggestWidget.background",J.CgL,x.kg("editorSuggestWidgetBackground","Background color of the suggest widget.")),(0,J.x1A)("editorSuggestWidget.border",J.sIe,x.kg("editorSuggestWidgetBorder","Border color of the suggest widget."));const Ie=(0,J.x1A)("editorSuggestWidget.foreground",J.By2,x.kg("editorSuggestWidgetForeground","Foreground color of the suggest widget."));(0,J.x1A)("editorSuggestWidget.selectedForeground",J.nH,x.kg("editorSuggestWidgetSelectedForeground","Foreground color of the selected entry in the suggest widget.")),(0,J.x1A)("editorSuggestWidget.selectedIconForeground",J.c7i,x.kg("editorSuggestWidgetSelectedIconForeground","Icon foreground color of the selected entry in the suggest widget."));const Oe=(0,J.x1A)("editorSuggestWidget.selectedBackground",J.AlL,x.kg("editorSuggestWidgetSelectedBackground","Background color of the selected entry in the suggest widget."));(0,J.x1A)("editorSuggestWidget.highlightForeground",J.QI5,x.kg("editorSuggestWidgetHighlightForeground","Color of the match highlights in the suggest widget.")),(0,J.x1A)("editorSuggestWidget.focusHighlightForeground",J.eMz,x.kg("editorSuggestWidgetFocusHighlightForeground","Color of the match highlights in the suggest widget when an item is focused.")),(0,J.x1A)("editorSuggestWidgetStatus.foreground",(0,J.JO0)(Ie,.5),x.kg("editorSuggestWidgetStatusForeground","Foreground color of the suggest widget status."));class De{constructor(e,t){this._service=e,this._key=`suggestWidget.size/${t.getEditorType()}/${t instanceof j.t}`}restore(){const e=this._service.get(this._key,0)??"";try{const t=JSON.parse(e);if(B.fg.is(t))return B.fg.lift(t)}catch{}}store(e){this._service.store(this._key,JSON.stringify(e),0,1)}reset(){this._service.remove(this._key,0)}}let Me=class{static{xe=this}static{this.LOADING_MESSAGE=x.kg("suggestWidget.loading","Loading...")}static{this.NO_SUGGESTIONS_MESSAGE=x.kg("suggestWidget.noSuggestions","No suggestions.")}constructor(e,t,i,s,n){this.editor=e,this._storageService=t,this._state=0,this._isAuto=!1,this._pendingLayout=new h.HE,this._pendingShowDetails=new h.HE,this._ignoreFocusEvents=!1,this._forceRenderingAbove=!1,this._explainMode=!1,this._showTimeout=new V.pc,this._disposables=new h.Cm,this._onDidSelect=new c.fV,this._onDidFocus=new c.fV,this._onDidHide=new c.vl,this._onDidShow=new c.vl,this.onDidSelect=this._onDidSelect.event,this.onDidFocus=this._onDidFocus.event,this.onDidHide=this._onDidHide.event,this.onDidShow=this._onDidShow.event,this._onDetailsKeydown=new c.vl,this.onDetailsKeyDown=this._onDetailsKeydown.event,this.element=new ie.v,this.element.domNode.classList.add("editor-widget","suggest-widget"),this._contentWidget=new Pe(this,e),this._persistedSize=new De(t,e);class r{constructor(e,t,i=!1,s=!1){this.persistedSize=e,this.currentSize=t,this.persistHeight=i,this.persistWidth=s}}let o;this._disposables.add(this.element.onDidWillResize((()=>{this._contentWidget.lockPreference(),o=new r(this._persistedSize.restore(),this.element.size)}))),this._disposables.add(this.element.onDidResize((e=>{if(this._resize(e.dimension.width,e.dimension.height),o&&(o.persistHeight=o.persistHeight||!!e.north||!!e.south,o.persistWidth=o.persistWidth||!!e.east||!!e.west),e.done){if(o){const{itemHeight:e,defaultSize:t}=this.getLayoutInfo(),i=Math.round(e/2);let{width:s,height:n}=this.element.size;(!o.persistHeight||Math.abs(o.currentSize.height-n)<=i)&&(n=o.persistedSize?.height??t.height),(!o.persistWidth||Math.abs(o.currentSize.width-s)<=i)&&(s=o.persistedSize?.width??t.width),this._persistedSize.store(new B.fg(s,n))}this._contentWidget.unlockPreference(),o=void 0}}))),this._messageElement=B.BC(this.element.domNode,B.$(".message")),this._listElement=B.BC(this.element.domNode,B.$(".tree"));const a=this._disposables.add(n.createInstance(de,this.editor));a.onDidClose(this.toggleDetails,this,this._disposables),this._details=new ue(a,this.editor);const l=()=>this.element.domNode.classList.toggle("no-icons",!this.editor.getOption(119).showIcons);l();const d=n.createInstance(Le,this.editor);this._disposables.add(d),this._disposables.add(d.onDidToggleDetails((()=>this.toggleDetails()))),this._list=new W.B8("SuggestWidget",this._listElement,{getHeight:e=>this.getLayoutInfo().itemHeight,getTemplateId:e=>"suggestion"},[d],{alwaysConsumeMouseWheel:!0,useShadows:!1,mouseSupport:!1,multipleSelectionSupport:!1,accessibilityProvider:{getRole:()=>"option",getWidgetAriaLabel:()=>x.kg("suggest","Suggest"),getWidgetRole:()=>"listbox",getAriaLabel:e=>{let t=e.textLabel;if("string"!==typeof e.completion.label){const{detail:i,description:s}=e.completion.label;i&&s?t=x.kg("label.full","{0} {1}, {2}",t,i,s):i?t=x.kg("label.detail","{0} {1}",t,i):s&&(t=x.kg("label.desc","{0}, {1}",t,s))}if(!e.isResolved||!this._isDetailsVisible())return t;const{documentation:i,detail:s}=e.completion,n=G.GP("{0}{1}",s||"",i?"string"===typeof i?i:i.value:"");return x.kg("ariaCurrenttSuggestionReadDetails","{0}, docs: {1}",t,n)}}}),this._list.style((0,ke.t8)({listInactiveFocusBackground:Oe,listInactiveFocusOutline:J.buw})),this._status=n.createInstance(X,this.element.domNode,I.dt);const u=()=>this.element.domNode.classList.toggle("with-status-bar",this.editor.getOption(119).showStatusBar);u(),this._disposables.add(s.onDidColorThemeChange((e=>this._onThemeChange(e)))),this._onThemeChange(s.getColorTheme()),this._disposables.add(this._list.onMouseDown((e=>this._onListMouseDownOrTap(e)))),this._disposables.add(this._list.onTap((e=>this._onListMouseDownOrTap(e)))),this._disposables.add(this._list.onDidChangeSelection((e=>this._onListSelection(e)))),this._disposables.add(this._list.onDidChangeFocus((e=>this._onListFocus(e)))),this._disposables.add(this.editor.onDidChangeCursorSelection((()=>this._onCursorSelectionChanged()))),this._disposables.add(this.editor.onDidChangeConfiguration((e=>{e.hasChanged(119)&&(u(),l()),this._completionModel&&(e.hasChanged(50)||e.hasChanged(120)||e.hasChanged(121))&&this._list.splice(0,this._list.length,this._completionModel.items)}))),this._ctxSuggestWidgetVisible=I.ob.Visible.bindTo(i),this._ctxSuggestWidgetDetailsVisible=I.ob.DetailsVisible.bindTo(i),this._ctxSuggestWidgetMultipleSuggestions=I.ob.MultipleSuggestions.bindTo(i),this._ctxSuggestWidgetHasFocusedSuggestion=I.ob.HasFocusedSuggestion.bindTo(i),this._disposables.add(B.b2(this._details.widget.domNode,"keydown",(e=>{this._onDetailsKeydown.fire(e)}))),this._disposables.add(this.editor.onMouseDown((e=>this._onEditorMouseDown(e))))}dispose(){this._details.widget.dispose(),this._details.dispose(),this._list.dispose(),this._status.dispose(),this._disposables.dispose(),this._loadingTimeout?.dispose(),this._pendingLayout.dispose(),this._pendingShowDetails.dispose(),this._showTimeout.dispose(),this._contentWidget.dispose(),this.element.dispose()}_onEditorMouseDown(e){this._details.widget.domNode.contains(e.target.element)?this._details.widget.domNode.focus():this.element.domNode.contains(e.target.element)&&this.editor.focus()}_onCursorSelectionChanged(){0!==this._state&&this._contentWidget.layout()}_onListMouseDownOrTap(e){"undefined"!==typeof e.element&&"undefined"!==typeof e.index&&(e.browserEvent.preventDefault(),e.browserEvent.stopPropagation(),this._select(e.element,e.index))}_onListSelection(e){e.elements.length&&this._select(e.elements[0],e.indexes[0])}_select(e,t){const i=this._completionModel;i&&(this._onDidSelect.fire({item:e,index:t,model:i}),this.editor.focus())}_onThemeChange(e){this._details.widget.borderWidth=(0,ee.Bb)(e.type)?2:1}_onListFocus(e){if(this._ignoreFocusEvents)return;if(!e.elements.length)return this._currentSuggestionDetails&&(this._currentSuggestionDetails.cancel(),this._currentSuggestionDetails=void 0,this._focusedItem=void 0),this.editor.setAriaOptions({activeDescendant:void 0}),void this._ctxSuggestWidgetHasFocusedSuggestion.set(!1);if(!this._completionModel)return;this._ctxSuggestWidgetHasFocusedSuggestion.set(!0);const t=e.elements[0],i=e.indexes[0];t!==this._focusedItem&&(this._currentSuggestionDetails?.cancel(),this._currentSuggestionDetails=void 0,this._focusedItem=t,this._list.reveal(i),this._currentSuggestionDetails=(0,V.SS)((async e=>{const i=(0,V.EQ)((()=>{this._isDetailsVisible()&&this.showDetails(!0)}),250),s=e.onCancellationRequested((()=>i.dispose()));try{return await t.resolve(e)}finally{i.dispose(),s.dispose()}})),this._currentSuggestionDetails.then((()=>{i>=this._list.length||t!==this._list.element(i)||(this._ignoreFocusEvents=!0,this._list.splice(i,1,[t]),this._list.setFocus([i]),this._ignoreFocusEvents=!1,this._isDetailsVisible()?this.showDetails(!1):this.element.domNode.classList.remove("docs-side"),this.editor.setAriaOptions({activeDescendant:ye(i)}))})).catch(a.dz)),this._onDidFocus.fire({item:t,index:i,model:this._completionModel})}_setState(e){if(this._state!==e)switch(this._state=e,this.element.domNode.classList.toggle("frozen",4===e),this.element.domNode.classList.remove("message"),e){case 0:B.jD(this._messageElement,this._listElement,this._status.element),this._details.hide(!0),this._status.hide(),this._contentWidget.hide(),this._ctxSuggestWidgetVisible.reset(),this._ctxSuggestWidgetMultipleSuggestions.reset(),this._ctxSuggestWidgetHasFocusedSuggestion.reset(),this._showTimeout.cancel(),this.element.domNode.classList.remove("visible"),this._list.splice(0,this._list.length),this._focusedItem=void 0,this._cappedHeight=void 0,this._explainMode=!1;break;case 1:this.element.domNode.classList.add("message"),this._messageElement.textContent=xe.LOADING_MESSAGE,B.jD(this._listElement,this._status.element),B.WU(this._messageElement),this._details.hide(),this._show(),this._focusedItem=void 0,(0,n.h5)(xe.LOADING_MESSAGE);break;case 2:this.element.domNode.classList.add("message"),this._messageElement.textContent=xe.NO_SUGGESTIONS_MESSAGE,B.jD(this._listElement,this._status.element),B.WU(this._messageElement),this._details.hide(),this._show(),this._focusedItem=void 0,(0,n.h5)(xe.NO_SUGGESTIONS_MESSAGE);break;case 3:case 4:B.jD(this._messageElement),B.WU(this._listElement,this._status.element),this._show();break;case 5:B.jD(this._messageElement),B.WU(this._listElement,this._status.element),this._details.show(),this._show()}}_show(){this._status.show(),this._contentWidget.show(),this._layout(this._persistedSize.restore()),this._ctxSuggestWidgetVisible.set(!0),this._showTimeout.cancelAndSet((()=>{this.element.domNode.classList.add("visible"),this._onDidShow.fire(this)}),100)}showTriggered(e,t){0===this._state&&(this._contentWidget.setPosition(this.editor.getPosition()),this._isAuto=!!e,this._isAuto||(this._loadingTimeout=(0,V.EQ)((()=>this._setState(1)),t)))}showSuggestions(e,t,i,s,n){if(this._contentWidget.setPosition(this.editor.getPosition()),this._loadingTimeout?.dispose(),this._currentSuggestionDetails?.cancel(),this._currentSuggestionDetails=void 0,this._completionModel!==e&&(this._completionModel=e),i&&2!==this._state&&0!==this._state)return void this._setState(4);const r=this._completionModel.items.length,o=0===r;if(this._ctxSuggestWidgetMultipleSuggestions.set(r>1),o)return this._setState(s?0:2),void(this._completionModel=void 0);this._focusedItem=void 0,this._onDidFocus.pause(),this._onDidSelect.pause();try{this._list.splice(0,this._list.length,this._completionModel.items),this._setState(i?4:3),this._list.reveal(t,0),this._list.setFocus(n?[]:[t])}finally{this._onDidFocus.resume(),this._onDidSelect.resume()}this._pendingLayout.value=B.Oq(B.zk(this.element.domNode),(()=>{this._pendingLayout.clear(),this._layout(this.element.size),this._details.widget.domNode.classList.remove("focused")}))}focusSelected(){this._list.length>0&&this._list.setFocus([0])}selectNextPage(){switch(this._state){case 0:return!1;case 5:return this._details.widget.pageDown(),!0;case 1:return!this._isAuto;default:return this._list.focusNextPage(),!0}}selectNext(){switch(this._state){case 0:return!1;case 1:return!this._isAuto;default:return this._list.focusNext(1,!0),!0}}selectLast(){switch(this._state){case 0:return!1;case 5:return this._details.widget.scrollBottom(),!0;case 1:return!this._isAuto;default:return this._list.focusLast(),!0}}selectPreviousPage(){switch(this._state){case 0:return!1;case 5:return this._details.widget.pageUp(),!0;case 1:return!this._isAuto;default:return this._list.focusPreviousPage(),!0}}selectPrevious(){switch(this._state){case 0:return!1;case 1:return!this._isAuto;default:return this._list.focusPrevious(1,!0),!1}}selectFirst(){switch(this._state){case 0:return!1;case 5:return this._details.widget.scrollTop(),!0;case 1:return!this._isAuto;default:return this._list.focusFirst(),!0}}getFocusedItem(){if(0!==this._state&&2!==this._state&&1!==this._state&&this._completionModel&&this._list.getFocus().length>0)return{item:this._list.getFocusedElements()[0],index:this._list.getFocus()[0],model:this._completionModel}}toggleDetailsFocus(){5===this._state?(this._setState(3),this._details.widget.domNode.classList.remove("focused")):3===this._state&&this._isDetailsVisible()&&(this._setState(5),this._details.widget.domNode.classList.add("focused"))}toggleDetails(){this._isDetailsVisible()?(this._pendingShowDetails.clear(),this._ctxSuggestWidgetDetailsVisible.set(!1),this._setDetailsVisible(!1),this._details.hide(),this.element.domNode.classList.remove("shows-details")):!he(this._list.getFocusedElements()[0])&&!this._explainMode||3!==this._state&&5!==this._state&&4!==this._state||(this._ctxSuggestWidgetDetailsVisible.set(!0),this._setDetailsVisible(!0),this.showDetails(!1))}showDetails(e){this._pendingShowDetails.value=B.Oq(B.zk(this.element.domNode),(()=>{this._pendingShowDetails.clear(),this._details.show(),e?this._details.widget.renderLoading():this._details.widget.renderItem(this._list.getFocusedElements()[0],this._explainMode),this._details.widget.isEmpty?this._details.hide():(this._positionDetails(),this.element.domNode.classList.add("shows-details")),this.editor.focus()}))}toggleExplainMode(){this._list.getFocusedElements()[0]&&(this._explainMode=!this._explainMode,this._isDetailsVisible()?this.showDetails(!1):this.toggleDetails())}resetPersistedSize(){this._persistedSize.reset()}hideWidget(){this._pendingLayout.clear(),this._pendingShowDetails.clear(),this._loadingTimeout?.dispose(),this._setState(0),this._onDidHide.fire(this),this.element.clearSashHoverState();const e=this._persistedSize.restore(),t=Math.ceil(4.3*this.getLayoutInfo().itemHeight);e&&e.heightr&&(n=r);const o=this._completionModel?this._completionModel.stats.pLabelLen*i.typicalHalfwidthCharacterWidth:n,a=i.statusBarHeight+this._list.contentHeight+i.borderHeight,c=i.itemHeight+i.statusBarHeight,l=B.BK(this.editor.getDomNode()),h=this.editor.getScrolledVisiblePosition(this.editor.getPosition()),d=l.top+h.top+h.height,u=Math.min(t.height-d-i.verticalPadding,a),g=l.top+h.top-i.verticalPadding,p=Math.min(g,a);let m=Math.min(Math.max(p,u)+i.borderHeight,a);s===this._cappedHeight?.capped&&(s=this._cappedHeight.wanted),sm&&(s=m);const f=150;s>u||this._forceRenderingAbove&&g>f?(this._contentWidget.setPreference(1),this.element.enableSashes(!0,!0,!1,!1),m=p):(this._contentWidget.setPreference(2),this.element.enableSashes(!1,!0,!0,!1),m=u),this.element.preferredSize=new B.fg(o,i.defaultSize.height),this.element.maxSize=new B.fg(r,m),this.element.minSize=new B.fg(220,c),this._cappedHeight=s===a?{wanted:this._cappedHeight?.wanted??e.height,capped:s}:void 0}this._resize(n,s)}_resize(e,t){const{width:i,height:s}=this.element.maxSize;e=Math.min(i,e),t=Math.min(s,t);const{statusBarHeight:n}=this.getLayoutInfo();this._list.layout(t-n,e),this._listElement.style.height=t-n+"px",this.element.layout(t,e),this._contentWidget.layout(),this._positionDetails()}_positionDetails(){this._isDetailsVisible()&&this._details.placeAtAnchor(this.element.domNode,2===this._contentWidget.getPosition()?.preference[0])}getLayoutInfo(){const e=this.editor.getOption(50),t=(0,z.qE)(this.editor.getOption(121)||e.lineHeight,8,1e3),i=this.editor.getOption(119).showStatusBar&&2!==this._state&&1!==this._state?t:0,s=this._details.widget.borderWidth,n=2*s;return{itemHeight:t,statusBarHeight:i,borderWidth:s,borderHeight:n,typicalHalfwidthCharacterWidth:e.typicalHalfwidthCharacterWidth,verticalPadding:22,horizontalPadding:14,defaultSize:new B.fg(430,i+12*t+n)}}_isDetailsVisible(){return this._storageService.getBoolean("expandSuggestionDocs",0,!1)}_setDetailsVisible(e){this._storageService.store("expandSuggestionDocs",e,0,0)}forceRenderingAbove(){this._forceRenderingAbove||(this._forceRenderingAbove=!0,this._layout(this._persistedSize.restore()))}stopForceRenderingAbove(){this._forceRenderingAbove=!1}};Me=xe=Ae([Ne(1,Z.CS),Ne(2,y.fN),Ne(3,te.Gy),Ne(4,A._Y)],Me);class Pe{constructor(e,t){this._widget=e,this._editor=t,this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this._preferenceLocked=!1,this._added=!1,this._hidden=!1}dispose(){this._added&&(this._added=!1,this._editor.removeContentWidget(this))}getId(){return"editor.widget.suggestWidget"}getDomNode(){return this._widget.element.domNode}show(){this._hidden=!1,this._added||(this._added=!0,this._editor.addContentWidget(this))}hide(){this._hidden||(this._hidden=!0,this.layout())}layout(){this._editor.layoutContentWidget(this)}getPosition(){return!this._hidden&&this._position&&this._preference?{position:this._position,preference:[this._preference]}:null}beforeRender(){const{height:e,width:t}=this._widget.element.size,{borderWidth:i,horizontalPadding:s}=this._widget.getLayoutInfo();return new B.fg(t+2*i+s,e+2*i)}afterRender(e){this._widget._afterRender(e)}setPreference(e){this._preferenceLocked||(this._preference=e)}lockPreference(){this._preferenceLocked=!0}unlockPreference(){this._preferenceLocked=!1}setPosition(e){this._position=e}}var Fe,Ue=i(90651),He=i(89403),Be=i(85600),We=i(87289),Ve=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ze=function(e,t){return function(i,s){t(i,s,e)}};class Ge{constructor(e,t){this._model=e,this._position=t,this._decorationOptions=We.kI.register({description:"suggest-line-suffix",stickiness:1});if(e.getLineMaxColumn(t.lineNumber)!==t.column){const i=e.getOffsetAt(t),s=e.getPositionAt(i+1);e.changeDecorations((e=>{this._marker&&e.removeDecoration(this._marker),this._marker=e.addDecoration(v.Q.fromPositions(t,s),this._decorationOptions)}))}}dispose(){this._marker&&!this._model.isDisposed()&&this._model.changeDecorations((e=>{e.removeDecoration(this._marker),this._marker=void 0}))}delta(e){if(this._model.isDisposed()||this._position.lineNumber!==e.lineNumber)return 0;if(this._marker){const t=this._model.getDecorationRange(this._marker);return this._model.getOffsetAt(t.getStartPosition())-this._model.getOffsetAt(e)}return this._model.getLineMaxColumn(e.lineNumber)-e.column}}let je=class{static{Fe=this}static{this.ID="editor.contrib.suggestController"}static get(e){return e.getContribution(Fe.ID)}constructor(e,t,i,s,n,r,o){this._memoryService=t,this._commandService=i,this._contextKeyService=s,this._instantiationService=n,this._logService=r,this._telemetryService=o,this._lineSuffix=new h.HE,this._toDispose=new h.Cm,this._selectors=new Ke((e=>e.priority)),this._onWillInsertSuggestItem=new c.vl,this.onWillInsertSuggestItem=this._onWillInsertSuggestItem.event,this.editor=e,this.model=n.createInstance(U.Y,this.editor),this._selectors.register({priority:0,select:(e,t,i)=>this._memoryService.select(e,t,i)});const a=I.ob.InsertMode.bindTo(s);a.set(e.getOption(119).insertMode),this._toDispose.add(this.model.onDidTrigger((()=>a.set(e.getOption(119).insertMode)))),this.widget=this._toDispose.add(new B.Ij((0,B.zk)(e.getDomNode()),(()=>{const e=this._instantiationService.createInstance(Me,this.editor);this._toDispose.add(e),this._toDispose.add(e.onDidSelect((e=>this._insertSuggestion(e,0)),this));const t=new F(this.editor,e,this.model,(e=>this._insertSuggestion(e,2)));this._toDispose.add(t);const i=I.ob.MakesTextEdit.bindTo(this._contextKeyService),s=I.ob.HasInsertAndReplaceRange.bindTo(this._contextKeyService),n=I.ob.CanResolve.bindTo(this._contextKeyService);return this._toDispose.add((0,h.s)((()=>{i.reset(),s.reset(),n.reset()}))),this._toDispose.add(e.onDidFocus((({item:e})=>{const t=this.editor.getPosition(),r=e.editStart.column,o=t.column;let a=!0;if("smart"===this.editor.getOption(1)&&2===this.model.state&&!e.completion.additionalTextEdits&&!(4&e.completion.insertTextRules)&&o-r===e.completion.insertText.length){a=this.editor.getModel().getValueInRange({startLineNumber:t.lineNumber,startColumn:r,endLineNumber:t.lineNumber,endColumn:o})!==e.completion.insertText}i.set(a),s.set(!_.y.equals(e.editInsertEnd,e.editReplaceEnd)),n.set(Boolean(e.provider.resolveCompletionItem)||Boolean(e.completion.documentation)||e.completion.detail!==e.completion.label)}))),this._toDispose.add(e.onDetailsKeyDown((e=>{e.toKeyCodeChord().equals(new l.dG(!0,!1,!1,!1,33))||d.zx&&e.toKeyCodeChord().equals(new l.dG(!1,!1,!1,!0,33))?e.stopPropagation():e.toKeyCodeChord().isModifierKey()||this.editor.focus()}))),e}))),this._overtypingCapturer=this._toDispose.add(new B.Ij((0,B.zk)(e.getDomNode()),(()=>this._toDispose.add(new H(this.editor,this.model))))),this._alternatives=this._toDispose.add(new B.Ij((0,B.zk)(e.getDomNode()),(()=>this._toDispose.add(new M(this.editor,this._contextKeyService))))),this._toDispose.add(n.createInstance(L,e)),this._toDispose.add(this.model.onDidTrigger((e=>{this.widget.value.showTriggered(e.auto,e.shy?250:50),this._lineSuffix.value=new Ge(this.editor.getModel(),e.position)}))),this._toDispose.add(this.model.onDidSuggest((e=>{if(e.triggerOptions.shy)return;let t=-1;for(const s of this._selectors.itemsOrderedByPriorityDesc)if(t=s.select(this.editor.getModel(),this.editor.getPosition(),e.completionModel.items),-1!==t)break;if(-1===t&&(t=0),0===this.model.state)return;let i=!1;if(e.triggerOptions.auto){const t=this.editor.getOption(119);"never"===t.selectionMode||"always"===t.selectionMode?i="never"===t.selectionMode:"whenTriggerCharacter"===t.selectionMode?i=1!==e.triggerOptions.triggerKind:"whenQuickSuggestion"===t.selectionMode&&(i=1===e.triggerOptions.triggerKind&&!e.triggerOptions.refilter)}this.widget.value.showSuggestions(e.completionModel,t,e.isFrozen,e.triggerOptions.auto,i)}))),this._toDispose.add(this.model.onDidCancel((e=>{e.retrigger||this.widget.value.hideWidget()}))),this._toDispose.add(this.editor.onDidBlurEditorWidget((()=>{this.model.cancel(),this.model.clear()})));const u=I.ob.AcceptSuggestionsOnEnter.bindTo(s),g=()=>{const e=this.editor.getOption(1);u.set("on"===e||"smart"===e)};this._toDispose.add(this.editor.onDidChangeConfiguration((()=>g()))),g()}dispose(){this._alternatives.dispose(),this._toDispose.dispose(),this.widget.dispose(),this.model.dispose(),this._lineSuffix.dispose(),this._onWillInsertSuggestItem.dispose()}_insertSuggestion(e,t){if(!e||!e.item)return this._alternatives.value.reset(),this.model.cancel(),void this.model.clear();if(!this.editor.hasModel())return;const i=E.O.get(this.editor);if(!i)return;this._onWillInsertSuggestItem.fire({item:e.item});const s=this.editor.getModel(),n=s.getAlternativeVersionId(),{item:r}=e,c=[],l=new o.Qi;1&t||this.editor.pushUndoStop();const h=this.getOverwriteInfo(r,Boolean(8&t));this._memoryService.memorize(s,this.editor.getPosition(),r);const d=r.isResolved;let g=-1,m=-1;if(Array.isArray(r.completion.additionalTextEdits)){this.model.cancel();const e=p.D.capture(this.editor);this.editor.executeEdits("suggestController.additionalTextEdits.sync",r.completion.additionalTextEdits.map((e=>{let t=v.Q.lift(e.range);if(t.startLineNumber===r.position.lineNumber&&t.startColumn>r.position.column){const e=this.editor.getPosition().column-r.position.column,i=e,s=v.Q.spansMultipleLines(t)?0:e;t=new v.Q(t.startLineNumber,t.startColumn+i,t.endLineNumber,t.endColumn+s)}return f.k.replaceMove(t,e.text)}))),e.restoreRelativeVerticalPositionOfCursor(this.editor)}else if(!d){const e=new u.W;let i;const n=s.onDidChangeContent((e=>{if(e.isFlush)return l.cancel(),void n.dispose();for(const t of e.changes){const e=v.Q.getEndPosition(t.range);i&&!_.y.isBefore(e,i)||(i=e)}})),o=t;t|=2;let a=!1;const h=this.editor.onWillType((()=>{h.dispose(),a=!0,2&o||this.editor.pushUndoStop()}));c.push(r.resolve(l.token).then((()=>{if(!r.completion.additionalTextEdits||l.token.isCancellationRequested)return;if(i&&r.completion.additionalTextEdits.some((e=>_.y.isBefore(i,v.Q.getStartPosition(e.range)))))return!1;a&&this.editor.pushUndoStop();const e=p.D.capture(this.editor);return this.editor.executeEdits("suggestController.additionalTextEdits.async",r.completion.additionalTextEdits.map((e=>f.k.replaceMove(v.Q.lift(e.range),e.text)))),e.restoreRelativeVerticalPositionOfCursor(this.editor),!a&&2&o||this.editor.pushUndoStop(),!0})).then((t=>{this._logService.trace("[suggest] async resolving of edits DONE (ms, applied?)",e.elapsed(),t),m=!0===t?1:!1===t?0:-2})).finally((()=>{n.dispose(),h.dispose()})))}let{insertText:C}=r.completion;if(4&r.completion.insertTextRules||(C=b.fr.escape(C)),this.model.cancel(),i.insert(C,{overwriteBefore:h.overwriteBefore,overwriteAfter:h.overwriteAfter,undoStopBefore:!1,undoStopAfter:!1,adjustWhitespace:!(1&r.completion.insertTextRules),clipboardText:e.model.clipboardText,overtypingCapturer:this._overtypingCapturer.value}),2&t||this.editor.pushUndoStop(),r.completion.command)if(r.completion.command.id===Ye.id)this.model.trigger({auto:!0,retrigger:!0});else{const e=new u.W;c.push(this._commandService.executeCommand(r.completion.command.id,...r.completion.command.arguments?[...r.completion.command.arguments]:[]).catch((e=>{r.completion.extensionId?(0,a.M_)(e):(0,a.dz)(e)})).finally((()=>{g=e.elapsed()})))}4&t&&this._alternatives.value.set(e,(e=>{for(l.cancel();s.canUndo();){n!==s.getAlternativeVersionId()&&s.undo(),this._insertSuggestion(e,3|(8&t?8:0));break}})),this._alertCompletionItem(r),Promise.all(c).finally((()=>{this._reportSuggestionAcceptedTelemetry(r,s,d,g,m,e.index,e.model.items),this.model.clear(),l.dispose()}))}_reportSuggestionAcceptedTelemetry(e,t,i,s,n,r,o){if(0===Math.floor(100*Math.random()))return;const a=new Map;for(let h=0;h1?c[0]:-1;this._telemetryService.publicLog2("suggest.acceptedSuggestion",{extensionId:e.extensionId?.value??"unknown",providerId:e.provider._debugDisplayName??"unknown",kind:e.completion.kind,basenameHash:(0,Be.tW)((0,He.P8)(t.uri)).toString(16),languageId:t.getLanguageId(),fileExtension:(0,He.LC)(t.uri),resolveInfo:e.provider.resolveCompletionItem?i?1:0:-1,resolveDuration:e.resolveDuration,commandDuration:s,additionalEditsAsync:n,index:r,firstIndex:l})}getOverwriteInfo(e,t){(0,g.j)(this.editor.hasModel());let i="replace"===this.editor.getOption(119).insertMode;t&&(i=!i);const s=e.position.column-e.editStart.column,n=(i?e.editReplaceEnd.column:e.editInsertEnd.column)-e.position.column;return{overwriteBefore:s+(this.editor.getPosition().column-e.position.column),overwriteAfter:n+(this._lineSuffix.value?this._lineSuffix.value.delta(this.editor.getPosition()):0)}}_alertCompletionItem(e){if((0,r.EI)(e.completion.additionalTextEdits)){const t=x.kg("aria.alert.snippet","Accepting '{0}' made {1} additional edits",e.textLabel,e.completion.additionalTextEdits.length);(0,n.xE)(t)}}triggerSuggest(e,t,i){this.editor.hasModel()&&(this.model.trigger({auto:t??!1,completionOptions:{providerFilter:e,kindFilter:i?new Set:void 0}}),this.editor.revealPosition(this.editor.getPosition(),0),this.editor.focus())}triggerSuggestAndAcceptBest(e){if(!this.editor.hasModel())return;const t=this.editor.getPosition(),i=()=>{t.equals(this.editor.getPosition())&&this._commandService.executeCommand(e.fallback)},s=e=>{if(4&e.completion.insertTextRules||e.completion.additionalTextEdits)return!0;const t=this.editor.getPosition(),i=e.editStart.column,s=t.column;if(s-i!==e.completion.insertText.length)return!0;return this.editor.getModel().getValueInRange({startLineNumber:t.lineNumber,startColumn:i,endLineNumber:t.lineNumber,endColumn:s})!==e.completion.insertText};c.Jh.once(this.model.onDidTrigger)((e=>{const t=[];c.Jh.any(this.model.onDidTrigger,this.model.onDidCancel)((()=>{(0,h.AS)(t),i()}),void 0,t),this.model.onDidSuggest((({completionModel:e})=>{if((0,h.AS)(t),0===e.items.length)return void i();const n=this._memoryService.select(this.editor.getModel(),this.editor.getPosition(),e.items),r=e.items[n];s(r)?(this.editor.pushUndoStop(),this._insertSuggestion({index:n,item:r,model:e},7)):i()}),void 0,t)})),this.model.trigger({auto:!1,shy:!0}),this.editor.revealPosition(t,0),this.editor.focus()}acceptSelectedSuggestion(e,t){const i=this.widget.value.getFocusedItem();let s=0;e&&(s|=4),t&&(s|=8),this._insertSuggestion(i,s)}acceptNextSuggestion(){this._alternatives.value.next()}acceptPrevSuggestion(){this._alternatives.value.prev()}cancelSuggestWidget(){this.model.cancel(),this.model.clear(),this.widget.value.hideWidget()}focusSuggestion(){this.widget.value.focusSelected()}selectNextSuggestion(){this.widget.value.selectNext()}selectNextPageSuggestion(){this.widget.value.selectNextPage()}selectLastSuggestion(){this.widget.value.selectLast()}selectPrevSuggestion(){this.widget.value.selectPrevious()}selectPrevPageSuggestion(){this.widget.value.selectPreviousPage()}selectFirstSuggestion(){this.widget.value.selectFirst()}toggleSuggestionDetails(){this.widget.value.toggleDetails()}toggleExplainMode(){this.widget.value.toggleExplainMode()}toggleSuggestionFocus(){this.widget.value.toggleDetailsFocus()}resetWidgetSize(){this.widget.value.resetPersistedSize()}forceRenderingAbove(){this.widget.value.forceRenderingAbove()}stopForceRenderingAbove(){this.widget.isInitialized&&this.widget.value.stopForceRenderingAbove()}registerSelector(e){return this._selectors.register(e)}};je=Fe=Ve([ze(1,S.GS),ze(2,k.d),ze(3,y.fN),ze(4,A._Y),ze(5,N.rr),ze(6,Ue.k)],je);class Ke{constructor(e){this.prioritySelector=e,this._items=new Array}register(e){if(-1!==this._items.indexOf(e))throw new Error("Value is already registered");return this._items.push(e),this._items.sort(((e,t)=>this.prioritySelector(t)-this.prioritySelector(e))),{dispose:()=>{const t=this._items.indexOf(e);t>=0&&this._items.splice(t,1)}}}get itemsOrderedByPriorityDesc(){return this._items}}class Ye extends m.ks{static{this.id="editor.action.triggerSuggest"}constructor(){super({id:Ye.id,label:x.kg("suggest.trigger.label","Trigger Suggest"),alias:"Trigger Suggest",precondition:y.M$.and(C.R.writable,C.R.hasCompletionItemProvider,I.ob.Visible.toNegated()),kbOpts:{kbExpr:C.R.textInputFocus,primary:2058,secondary:[2087],mac:{primary:266,secondary:[521,2087]},weight:100}})}run(e,t,i){const s=je.get(t);if(!s)return;let n;i&&"object"===typeof i&&!0===i.auto&&(n=!0),s.triggerSuggest(void 0,n,void 0)}}(0,m.HW)(je.ID,je,2),(0,m.Fl)(Ye);const qe=190,$e=m.DX.bindToContribution(je.get);(0,m.E_)(new $e({id:"acceptSelectedSuggestion",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion),handler(e){e.acceptSelectedSuggestion(!0,!1)},kbOpts:[{primary:2,kbExpr:y.M$.and(I.ob.Visible,C.R.textInputFocus),weight:qe},{primary:3,kbExpr:y.M$.and(I.ob.Visible,C.R.textInputFocus,I.ob.AcceptSuggestionsOnEnter,I.ob.MakesTextEdit),weight:qe}],menuOpts:[{menuId:I.dt,title:x.kg("accept.insert","Insert"),group:"left",order:1,when:I.ob.HasInsertAndReplaceRange.toNegated()},{menuId:I.dt,title:x.kg("accept.insert","Insert"),group:"left",order:1,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("insert"))},{menuId:I.dt,title:x.kg("accept.replace","Replace"),group:"left",order:1,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("replace"))}]})),(0,m.E_)(new $e({id:"acceptAlternativeSelectedSuggestion",precondition:y.M$.and(I.ob.Visible,C.R.textInputFocus,I.ob.HasFocusedSuggestion),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:1027,secondary:[1026]},handler(e){e.acceptSelectedSuggestion(!1,!0)},menuOpts:[{menuId:I.dt,group:"left",order:2,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("insert")),title:x.kg("accept.replace","Replace")},{menuId:I.dt,group:"left",order:2,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("replace")),title:x.kg("accept.insert","Insert")}]})),k.w.registerCommandAlias("acceptSelectedSuggestionOnEnter","acceptSelectedSuggestion"),(0,m.E_)(new $e({id:"hideSuggestWidget",precondition:I.ob.Visible,handler:e=>e.cancelSuggestWidget(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:9,secondary:[1033]}})),(0,m.E_)(new $e({id:"selectNextSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectNextSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:18,secondary:[2066],mac:{primary:18,secondary:[2066,300]}}})),(0,m.E_)(new $e({id:"selectNextPageSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectNextPageSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:12,secondary:[2060]}})),(0,m.E_)(new $e({id:"selectLastSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectLastSuggestion()})),(0,m.E_)(new $e({id:"selectPrevSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectPrevSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:16,secondary:[2064],mac:{primary:16,secondary:[2064,302]}}})),(0,m.E_)(new $e({id:"selectPrevPageSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectPrevPageSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:11,secondary:[2059]}})),(0,m.E_)(new $e({id:"selectFirstSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectFirstSuggestion()})),(0,m.E_)(new $e({id:"focusSuggestion",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion.negate()),handler:e=>e.focusSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2058,secondary:[2087],mac:{primary:266,secondary:[2087]}}})),(0,m.E_)(new $e({id:"focusAndAcceptSuggestion",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion.negate()),handler:e=>{e.focusSuggestion(),e.acceptSelectedSuggestion(!0,!1)}})),(0,m.E_)(new $e({id:"toggleSuggestionDetails",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion),handler:e=>e.toggleSuggestionDetails(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2058,secondary:[2087],mac:{primary:266,secondary:[2087]}},menuOpts:[{menuId:I.dt,group:"right",order:1,when:y.M$.and(I.ob.DetailsVisible,I.ob.CanResolve),title:x.kg("detail.more","Show Less")},{menuId:I.dt,group:"right",order:1,when:y.M$.and(I.ob.DetailsVisible.toNegated(),I.ob.CanResolve),title:x.kg("detail.less","Show More")}]})),(0,m.E_)(new $e({id:"toggleExplainMode",precondition:I.ob.Visible,handler:e=>e.toggleExplainMode(),kbOpts:{weight:100,primary:2138}})),(0,m.E_)(new $e({id:"toggleSuggestionFocus",precondition:I.ob.Visible,handler:e=>e.toggleSuggestionFocus(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2570,mac:{primary:778}}})),(0,m.E_)(new $e({id:"insertBestCompletion",precondition:y.M$.and(C.R.textInputFocus,y.M$.equals("config.editor.tabCompletion","on"),L.AtEnd,I.ob.Visible.toNegated(),M.OtherSuggestions.toNegated(),E.O.InSnippetMode.toNegated()),handler:(e,t)=>{e.triggerSuggestAndAcceptBest((0,g.Gv)(t)?{fallback:"tab",...t}:{fallback:"tab"})},kbOpts:{weight:qe,primary:2}})),(0,m.E_)(new $e({id:"insertNextSuggestion",precondition:y.M$.and(C.R.textInputFocus,y.M$.equals("config.editor.tabCompletion","on"),M.OtherSuggestions,I.ob.Visible.toNegated(),E.O.InSnippetMode.toNegated()),handler:e=>e.acceptNextSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2}})),(0,m.E_)(new $e({id:"insertPrevSuggestion",precondition:y.M$.and(C.R.textInputFocus,y.M$.equals("config.editor.tabCompletion","on"),M.OtherSuggestions,I.ob.Visible.toNegated(),E.O.InSnippetMode.toNegated()),handler:e=>e.acceptPrevSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:1026}})),(0,m.Fl)(class extends m.ks{constructor(){super({id:"editor.action.resetSuggestSize",label:x.kg("suggest.reset.label","Reset Suggest Widget Size"),alias:"Reset Suggest Widget Size",precondition:void 0})}run(e,t){je.get(t)?.resetWidgetSize()}})},91090:(e,t,i)=>{"use strict";i.d(t,{d:()=>s});class s{constructor(e){this.executor=e,this._didRun=!1}get value(){if(!this._didRun)try{this._value=this.executor()}catch(e){this._error=e}finally{this._didRun=!0}if(this._error)throw this._error;return this._value}get rawValue(){return this._value}}},91364:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M5 13.5h6a1.5 1.5 0 0 0 1.5-1.5V7.243a1.5 1.5 0 0 0-.44-1.061L8.819 2.939a1.5 1.5 0 0 0-1.06-.439H5A1.5 1.5 0 0 0 3.5 4v8A1.5 1.5 0 0 0 5 13.5m9-6.257a3 3 0 0 0-.879-2.122L9.88 1.88A3 3 0 0 0 7.757 1H5a3 3 0 0 0-3 3v8a3 3 0 0 0 3 3h6a3 3 0 0 0 3-3zM5 8.25a.75.75 0 0 1 .75-.75h4.5a.75.75 0 0 1 0 1.5h-4.5A.75.75 0 0 1 5 8.25m.75 2.25a.75.75 0 0 0 0 1.5h2.5a.75.75 0 0 0 0-1.5z",clipRule:"evenodd"}))},91508:(e,t,i)=>{"use strict";i.d(t,{$X:()=>q,AV:()=>r,BO:()=>g,Bm:()=>p,Bq:()=>d,DB:()=>T,E_:()=>G,GP:()=>a,HG:()=>E,LJ:()=>M,LU:()=>Z,Lv:()=>x,MV:()=>W,NB:()=>u,OS:()=>f,Q_:()=>A,Qp:()=>I,S8:()=>re,Ss:()=>Q,UD:()=>y,UU:()=>b,Vi:()=>O,W1:()=>R,Wd:()=>se,Wv:()=>k,Z5:()=>F,_J:()=>Y,aC:()=>K,bm:()=>h,eY:()=>_,en:()=>C,ih:()=>l,iy:()=>B,jy:()=>c,km:()=>H,lF:()=>w,lT:()=>S,m:()=>V,ne:()=>$,ns:()=>N,pc:()=>D,r_:()=>X,tk:()=>ee,tl:()=>oe,uz:()=>v,wB:()=>m,y_:()=>ae,zY:()=>J,z_:()=>P,zd:()=>L});var s=i(81788),n=i(91090);function r(e){return!e||"string"!==typeof e||0===e.trim().length}const o=/{(\d+)}/g;function a(e,...t){return 0===t.length?e:e.replace(o,(function(e,i){const s=parseInt(i,10);return isNaN(s)||s<0||s>=t.length?e:t[s]}))}function c(e){return e.replace(/[<>"'&]/g,(e=>{switch(e){case"<":return"<";case">":return">";case'"':return""";case"'":return"'";case"&":return"&"}return e}))}function l(e){return e.replace(/[<>&]/g,(function(e){switch(e){case"<":return"<";case">":return">";case"&":return"&";default:return e}}))}function h(e){return e.replace(/[\\\{\}\*\+\?\|\^\$\.\[\]\(\)]/g,"\\$&")}function d(e,t=" "){return g(u(e,t),t)}function u(e,t){if(!e||!t)return e;const i=t.length;if(0===i||0===e.length)return e;let s=0;for(;e.indexOf(t,s)===s;)s+=i;return e.substring(s)}function g(e,t){if(!e||!t)return e;const i=t.length,s=e.length;if(0===i||0===s)return e;let n=s,r=-1;for(;r=e.lastIndexOf(t,n-1),-1!==r&&r+i===n;){if(0===r)return"";n=r}return e.substring(0,n)}function p(e){return e.replace(/[\-\\\{\}\+\?\|\^\$\.\,\[\]\(\)\#\s]/g,"\\$&").replace(/[\*]/g,".*")}function m(e){return e.replace(/\*/g,"")}function f(e,t,i={}){if(!e)throw new Error("Cannot create regex from empty string");t||(e=h(e)),i.wholeWord&&(/\B/.test(e.charAt(0))||(e="\\b"+e),/\B/.test(e.charAt(e.length-1))||(e+="\\b"));let s="";return i.global&&(s+="g"),i.matchCase||(s+="i"),i.multiline&&(s+="m"),i.unicode&&(s+="u"),new RegExp(e,s)}function _(e){if("^"===e.source||"^$"===e.source||"$"===e.source||"^\\s*$"===e.source)return!1;return!(!e.exec("")||0!==e.lastIndex)}function v(e){return e.split(/\r\n|\r|\n/)}function C(e){const t=[],i=e.split(/(\r\n|\r|\n)/);for(let s=0;s=0;i--){const t=e.charCodeAt(i);if(32!==t&&9!==t)return i}return-1}function y(e,t){return et?1:0}function w(e,t,i=0,s=e.length,n=0,r=t.length){for(;ir)return 1}const o=s-i,a=r-n;return oa?1:0}function R(e,t){return L(e,t,0,e.length,0,t.length)}function L(e,t,i=0,s=e.length,n=0,r=t.length){for(;i=128||a>=128)return w(e.toLowerCase(),t.toLowerCase(),i,s,n,r);x(o)&&(o-=32),x(a)&&(a-=32);const c=o-a;if(0!==c)return c}const o=s-i,a=r-n;return oa?1:0}function T(e){return e>=48&&e<=57}function x(e){return e>=97&&e<=122}function k(e){return e>=65&&e<=90}function A(e,t){return e.length===t.length&&0===L(e,t)}function N(e,t){const i=t.length;return!(t.length>e.length)&&0===L(e,t,0,i)}function I(e,t){const i=Math.min(e.length,t.length);let s;for(s=0;s1){const s=e.charCodeAt(t-2);if(D(s))return P(s,i)}return i}(this._str,this._offset);return this._offset-=e>=65536?2:1,e}nextCodePoint(){const e=F(this._str,this._len,this._offset);return this._offset+=e>=65536?2:1,e}eol(){return this._offset>=this._len}}class H{get offset(){return this._iterator.offset}constructor(e,t=0){this._iterator=new U(e,t)}nextGraphemeLength(){const e=ie.getInstance(),t=this._iterator,i=t.offset;let s=e.getGraphemeBreakType(t.nextCodePoint());for(;!t.eol();){const i=t.offset,n=e.getGraphemeBreakType(t.nextCodePoint());if(te(s,n)){t.setOffset(i);break}s=n}return t.offset-i}prevGraphemeLength(){const e=ie.getInstance(),t=this._iterator,i=t.offset;let s=e.getGraphemeBreakType(t.prevCodePoint());for(;t.offset>0;){const i=t.offset,n=e.getGraphemeBreakType(t.prevCodePoint());if(te(n,s)){t.setOffset(i);break}s=n}return i-t.offset}eol(){return this._iterator.eol()}}function B(e,t){return new H(e,t).nextGraphemeLength()}function W(e,t){return new H(e,t).prevGraphemeLength()}function V(e,t){t>0&&M(e.charCodeAt(t))&&t--;const i=t+B(e,t);return[i-W(e,i),i]}let z;function G(e){return z||(z=/(?:[\u05BE\u05C0\u05C3\u05C6\u05D0-\u05F4\u0608\u060B\u060D\u061B-\u064A\u066D-\u066F\u0671-\u06D5\u06E5\u06E6\u06EE\u06EF\u06FA-\u0710\u0712-\u072F\u074D-\u07A5\u07B1-\u07EA\u07F4\u07F5\u07FA\u07FE-\u0815\u081A\u0824\u0828\u0830-\u0858\u085E-\u088E\u08A0-\u08C9\u200F\uFB1D\uFB1F-\uFB28\uFB2A-\uFD3D\uFD50-\uFDC7\uFDF0-\uFDFC\uFE70-\uFEFC]|\uD802[\uDC00-\uDD1B\uDD20-\uDE00\uDE10-\uDE35\uDE40-\uDEE4\uDEEB-\uDF35\uDF40-\uDFFF]|\uD803[\uDC00-\uDD23\uDE80-\uDEA9\uDEAD-\uDF45\uDF51-\uDF81\uDF86-\uDFF6]|\uD83A[\uDC00-\uDCCF\uDD00-\uDD43\uDD4B-\uDFFF]|\uD83B[\uDC00-\uDEBB])/),z.test(e)}const j=/^[\t\n\r\x20-\x7E]*$/;function K(e){return j.test(e)}const Y=/[\u2028\u2029]/;function q(e){return Y.test(e)}function $(e){return e>=11904&&e<=55215||e>=63744&&e<=64255||e>=65281&&e<=65374}function Q(e){return e>=127462&&e<=127487||8986===e||8987===e||9200===e||9203===e||e>=9728&&e<=10175||11088===e||11093===e||e>=127744&&e<=128591||e>=128640&&e<=128764||e>=128992&&e<=129008||e>=129280&&e<=129535||e>=129648&&e<=129782}const X=String.fromCharCode(65279);function Z(e){return!!(e&&e.length>0&&65279===e.charCodeAt(0))}function J(e,t=!1){return!!e&&(t&&(e=e.replace(/\\./g,"")),e.toLowerCase()!==e)}function ee(e){return(e%=52)<26?String.fromCharCode(97+e):String.fromCharCode(65+e-26)}function te(e,t){return 0===e?5!==t&&7!==t:(2!==e||3!==t)&&(4===e||2===e||3===e||(4===t||2===t||3===t||(8!==e||8!==t&&9!==t&&11!==t&&12!==t)&&((11!==e&&9!==e||9!==t&&10!==t)&&((12!==e&&10!==e||10!==t)&&(5!==t&&13!==t&&(7!==t&&(1!==e&&((13!==e||14!==t)&&(6!==e||6!==t)))))))))}class ie{static{this._INSTANCE=null}static getInstance(){return ie._INSTANCE||(ie._INSTANCE=new ie),ie._INSTANCE}constructor(){this._data=JSON.parse("[0,0,0,51229,51255,12,44061,44087,12,127462,127487,6,7083,7085,5,47645,47671,12,54813,54839,12,128678,128678,14,3270,3270,5,9919,9923,14,45853,45879,12,49437,49463,12,53021,53047,12,71216,71218,7,128398,128399,14,129360,129374,14,2519,2519,5,4448,4519,9,9742,9742,14,12336,12336,14,44957,44983,12,46749,46775,12,48541,48567,12,50333,50359,12,52125,52151,12,53917,53943,12,69888,69890,5,73018,73018,5,127990,127990,14,128558,128559,14,128759,128760,14,129653,129655,14,2027,2035,5,2891,2892,7,3761,3761,5,6683,6683,5,8293,8293,4,9825,9826,14,9999,9999,14,43452,43453,5,44509,44535,12,45405,45431,12,46301,46327,12,47197,47223,12,48093,48119,12,48989,49015,12,49885,49911,12,50781,50807,12,51677,51703,12,52573,52599,12,53469,53495,12,54365,54391,12,65279,65279,4,70471,70472,7,72145,72147,7,119173,119179,5,127799,127818,14,128240,128244,14,128512,128512,14,128652,128652,14,128721,128722,14,129292,129292,14,129445,129450,14,129734,129743,14,1476,1477,5,2366,2368,7,2750,2752,7,3076,3076,5,3415,3415,5,4141,4144,5,6109,6109,5,6964,6964,5,7394,7400,5,9197,9198,14,9770,9770,14,9877,9877,14,9968,9969,14,10084,10084,14,43052,43052,5,43713,43713,5,44285,44311,12,44733,44759,12,45181,45207,12,45629,45655,12,46077,46103,12,46525,46551,12,46973,46999,12,47421,47447,12,47869,47895,12,48317,48343,12,48765,48791,12,49213,49239,12,49661,49687,12,50109,50135,12,50557,50583,12,51005,51031,12,51453,51479,12,51901,51927,12,52349,52375,12,52797,52823,12,53245,53271,12,53693,53719,12,54141,54167,12,54589,54615,12,55037,55063,12,69506,69509,5,70191,70193,5,70841,70841,7,71463,71467,5,72330,72342,5,94031,94031,5,123628,123631,5,127763,127765,14,127941,127941,14,128043,128062,14,128302,128317,14,128465,128467,14,128539,128539,14,128640,128640,14,128662,128662,14,128703,128703,14,128745,128745,14,129004,129007,14,129329,129330,14,129402,129402,14,129483,129483,14,129686,129704,14,130048,131069,14,173,173,4,1757,1757,1,2200,2207,5,2434,2435,7,2631,2632,5,2817,2817,5,3008,3008,5,3201,3201,5,3387,3388,5,3542,3542,5,3902,3903,7,4190,4192,5,6002,6003,5,6439,6440,5,6765,6770,7,7019,7027,5,7154,7155,7,8205,8205,13,8505,8505,14,9654,9654,14,9757,9757,14,9792,9792,14,9852,9853,14,9890,9894,14,9937,9937,14,9981,9981,14,10035,10036,14,11035,11036,14,42654,42655,5,43346,43347,7,43587,43587,5,44006,44007,7,44173,44199,12,44397,44423,12,44621,44647,12,44845,44871,12,45069,45095,12,45293,45319,12,45517,45543,12,45741,45767,12,45965,45991,12,46189,46215,12,46413,46439,12,46637,46663,12,46861,46887,12,47085,47111,12,47309,47335,12,47533,47559,12,47757,47783,12,47981,48007,12,48205,48231,12,48429,48455,12,48653,48679,12,48877,48903,12,49101,49127,12,49325,49351,12,49549,49575,12,49773,49799,12,49997,50023,12,50221,50247,12,50445,50471,12,50669,50695,12,50893,50919,12,51117,51143,12,51341,51367,12,51565,51591,12,51789,51815,12,52013,52039,12,52237,52263,12,52461,52487,12,52685,52711,12,52909,52935,12,53133,53159,12,53357,53383,12,53581,53607,12,53805,53831,12,54029,54055,12,54253,54279,12,54477,54503,12,54701,54727,12,54925,54951,12,55149,55175,12,68101,68102,5,69762,69762,7,70067,70069,7,70371,70378,5,70720,70721,7,71087,71087,5,71341,71341,5,71995,71996,5,72249,72249,7,72850,72871,5,73109,73109,5,118576,118598,5,121505,121519,5,127245,127247,14,127568,127569,14,127777,127777,14,127872,127891,14,127956,127967,14,128015,128016,14,128110,128172,14,128259,128259,14,128367,128368,14,128424,128424,14,128488,128488,14,128530,128532,14,128550,128551,14,128566,128566,14,128647,128647,14,128656,128656,14,128667,128673,14,128691,128693,14,128715,128715,14,128728,128732,14,128752,128752,14,128765,128767,14,129096,129103,14,129311,129311,14,129344,129349,14,129394,129394,14,129413,129425,14,129466,129471,14,129511,129535,14,129664,129666,14,129719,129722,14,129760,129767,14,917536,917631,5,13,13,2,1160,1161,5,1564,1564,4,1807,1807,1,2085,2087,5,2307,2307,7,2382,2383,7,2497,2500,5,2563,2563,7,2677,2677,5,2763,2764,7,2879,2879,5,2914,2915,5,3021,3021,5,3142,3144,5,3263,3263,5,3285,3286,5,3398,3400,7,3530,3530,5,3633,3633,5,3864,3865,5,3974,3975,5,4155,4156,7,4229,4230,5,5909,5909,7,6078,6085,7,6277,6278,5,6451,6456,7,6744,6750,5,6846,6846,5,6972,6972,5,7074,7077,5,7146,7148,7,7222,7223,5,7416,7417,5,8234,8238,4,8417,8417,5,9000,9000,14,9203,9203,14,9730,9731,14,9748,9749,14,9762,9763,14,9776,9783,14,9800,9811,14,9831,9831,14,9872,9873,14,9882,9882,14,9900,9903,14,9929,9933,14,9941,9960,14,9974,9974,14,9989,9989,14,10006,10006,14,10062,10062,14,10160,10160,14,11647,11647,5,12953,12953,14,43019,43019,5,43232,43249,5,43443,43443,5,43567,43568,7,43696,43696,5,43765,43765,7,44013,44013,5,44117,44143,12,44229,44255,12,44341,44367,12,44453,44479,12,44565,44591,12,44677,44703,12,44789,44815,12,44901,44927,12,45013,45039,12,45125,45151,12,45237,45263,12,45349,45375,12,45461,45487,12,45573,45599,12,45685,45711,12,45797,45823,12,45909,45935,12,46021,46047,12,46133,46159,12,46245,46271,12,46357,46383,12,46469,46495,12,46581,46607,12,46693,46719,12,46805,46831,12,46917,46943,12,47029,47055,12,47141,47167,12,47253,47279,12,47365,47391,12,47477,47503,12,47589,47615,12,47701,47727,12,47813,47839,12,47925,47951,12,48037,48063,12,48149,48175,12,48261,48287,12,48373,48399,12,48485,48511,12,48597,48623,12,48709,48735,12,48821,48847,12,48933,48959,12,49045,49071,12,49157,49183,12,49269,49295,12,49381,49407,12,49493,49519,12,49605,49631,12,49717,49743,12,49829,49855,12,49941,49967,12,50053,50079,12,50165,50191,12,50277,50303,12,50389,50415,12,50501,50527,12,50613,50639,12,50725,50751,12,50837,50863,12,50949,50975,12,51061,51087,12,51173,51199,12,51285,51311,12,51397,51423,12,51509,51535,12,51621,51647,12,51733,51759,12,51845,51871,12,51957,51983,12,52069,52095,12,52181,52207,12,52293,52319,12,52405,52431,12,52517,52543,12,52629,52655,12,52741,52767,12,52853,52879,12,52965,52991,12,53077,53103,12,53189,53215,12,53301,53327,12,53413,53439,12,53525,53551,12,53637,53663,12,53749,53775,12,53861,53887,12,53973,53999,12,54085,54111,12,54197,54223,12,54309,54335,12,54421,54447,12,54533,54559,12,54645,54671,12,54757,54783,12,54869,54895,12,54981,55007,12,55093,55119,12,55243,55291,10,66045,66045,5,68325,68326,5,69688,69702,5,69817,69818,5,69957,69958,7,70089,70092,5,70198,70199,5,70462,70462,5,70502,70508,5,70750,70750,5,70846,70846,7,71100,71101,5,71230,71230,7,71351,71351,5,71737,71738,5,72000,72000,7,72160,72160,5,72273,72278,5,72752,72758,5,72882,72883,5,73031,73031,5,73461,73462,7,94192,94193,7,119149,119149,7,121403,121452,5,122915,122916,5,126980,126980,14,127358,127359,14,127535,127535,14,127759,127759,14,127771,127771,14,127792,127793,14,127825,127867,14,127897,127899,14,127945,127945,14,127985,127986,14,128000,128007,14,128021,128021,14,128066,128100,14,128184,128235,14,128249,128252,14,128266,128276,14,128335,128335,14,128379,128390,14,128407,128419,14,128444,128444,14,128481,128481,14,128499,128499,14,128526,128526,14,128536,128536,14,128543,128543,14,128556,128556,14,128564,128564,14,128577,128580,14,128643,128645,14,128649,128649,14,128654,128654,14,128660,128660,14,128664,128664,14,128675,128675,14,128686,128689,14,128695,128696,14,128705,128709,14,128717,128719,14,128725,128725,14,128736,128741,14,128747,128748,14,128755,128755,14,128762,128762,14,128981,128991,14,129009,129023,14,129160,129167,14,129296,129304,14,129320,129327,14,129340,129342,14,129356,129356,14,129388,129392,14,129399,129400,14,129404,129407,14,129432,129442,14,129454,129455,14,129473,129474,14,129485,129487,14,129648,129651,14,129659,129660,14,129671,129679,14,129709,129711,14,129728,129730,14,129751,129753,14,129776,129782,14,917505,917505,4,917760,917999,5,10,10,3,127,159,4,768,879,5,1471,1471,5,1536,1541,1,1648,1648,5,1767,1768,5,1840,1866,5,2070,2073,5,2137,2139,5,2274,2274,1,2363,2363,7,2377,2380,7,2402,2403,5,2494,2494,5,2507,2508,7,2558,2558,5,2622,2624,7,2641,2641,5,2691,2691,7,2759,2760,5,2786,2787,5,2876,2876,5,2881,2884,5,2901,2902,5,3006,3006,5,3014,3016,7,3072,3072,5,3134,3136,5,3157,3158,5,3260,3260,5,3266,3266,5,3274,3275,7,3328,3329,5,3391,3392,7,3405,3405,5,3457,3457,5,3536,3537,7,3551,3551,5,3636,3642,5,3764,3772,5,3895,3895,5,3967,3967,7,3993,4028,5,4146,4151,5,4182,4183,7,4226,4226,5,4253,4253,5,4957,4959,5,5940,5940,7,6070,6070,7,6087,6088,7,6158,6158,4,6432,6434,5,6448,6449,7,6679,6680,5,6742,6742,5,6754,6754,5,6783,6783,5,6912,6915,5,6966,6970,5,6978,6978,5,7042,7042,7,7080,7081,5,7143,7143,7,7150,7150,7,7212,7219,5,7380,7392,5,7412,7412,5,8203,8203,4,8232,8232,4,8265,8265,14,8400,8412,5,8421,8432,5,8617,8618,14,9167,9167,14,9200,9200,14,9410,9410,14,9723,9726,14,9733,9733,14,9745,9745,14,9752,9752,14,9760,9760,14,9766,9766,14,9774,9774,14,9786,9786,14,9794,9794,14,9823,9823,14,9828,9828,14,9833,9850,14,9855,9855,14,9875,9875,14,9880,9880,14,9885,9887,14,9896,9897,14,9906,9916,14,9926,9927,14,9935,9935,14,9939,9939,14,9962,9962,14,9972,9972,14,9978,9978,14,9986,9986,14,9997,9997,14,10002,10002,14,10017,10017,14,10055,10055,14,10071,10071,14,10133,10135,14,10548,10549,14,11093,11093,14,12330,12333,5,12441,12442,5,42608,42610,5,43010,43010,5,43045,43046,5,43188,43203,7,43302,43309,5,43392,43394,5,43446,43449,5,43493,43493,5,43571,43572,7,43597,43597,7,43703,43704,5,43756,43757,5,44003,44004,7,44009,44010,7,44033,44059,12,44089,44115,12,44145,44171,12,44201,44227,12,44257,44283,12,44313,44339,12,44369,44395,12,44425,44451,12,44481,44507,12,44537,44563,12,44593,44619,12,44649,44675,12,44705,44731,12,44761,44787,12,44817,44843,12,44873,44899,12,44929,44955,12,44985,45011,12,45041,45067,12,45097,45123,12,45153,45179,12,45209,45235,12,45265,45291,12,45321,45347,12,45377,45403,12,45433,45459,12,45489,45515,12,45545,45571,12,45601,45627,12,45657,45683,12,45713,45739,12,45769,45795,12,45825,45851,12,45881,45907,12,45937,45963,12,45993,46019,12,46049,46075,12,46105,46131,12,46161,46187,12,46217,46243,12,46273,46299,12,46329,46355,12,46385,46411,12,46441,46467,12,46497,46523,12,46553,46579,12,46609,46635,12,46665,46691,12,46721,46747,12,46777,46803,12,46833,46859,12,46889,46915,12,46945,46971,12,47001,47027,12,47057,47083,12,47113,47139,12,47169,47195,12,47225,47251,12,47281,47307,12,47337,47363,12,47393,47419,12,47449,47475,12,47505,47531,12,47561,47587,12,47617,47643,12,47673,47699,12,47729,47755,12,47785,47811,12,47841,47867,12,47897,47923,12,47953,47979,12,48009,48035,12,48065,48091,12,48121,48147,12,48177,48203,12,48233,48259,12,48289,48315,12,48345,48371,12,48401,48427,12,48457,48483,12,48513,48539,12,48569,48595,12,48625,48651,12,48681,48707,12,48737,48763,12,48793,48819,12,48849,48875,12,48905,48931,12,48961,48987,12,49017,49043,12,49073,49099,12,49129,49155,12,49185,49211,12,49241,49267,12,49297,49323,12,49353,49379,12,49409,49435,12,49465,49491,12,49521,49547,12,49577,49603,12,49633,49659,12,49689,49715,12,49745,49771,12,49801,49827,12,49857,49883,12,49913,49939,12,49969,49995,12,50025,50051,12,50081,50107,12,50137,50163,12,50193,50219,12,50249,50275,12,50305,50331,12,50361,50387,12,50417,50443,12,50473,50499,12,50529,50555,12,50585,50611,12,50641,50667,12,50697,50723,12,50753,50779,12,50809,50835,12,50865,50891,12,50921,50947,12,50977,51003,12,51033,51059,12,51089,51115,12,51145,51171,12,51201,51227,12,51257,51283,12,51313,51339,12,51369,51395,12,51425,51451,12,51481,51507,12,51537,51563,12,51593,51619,12,51649,51675,12,51705,51731,12,51761,51787,12,51817,51843,12,51873,51899,12,51929,51955,12,51985,52011,12,52041,52067,12,52097,52123,12,52153,52179,12,52209,52235,12,52265,52291,12,52321,52347,12,52377,52403,12,52433,52459,12,52489,52515,12,52545,52571,12,52601,52627,12,52657,52683,12,52713,52739,12,52769,52795,12,52825,52851,12,52881,52907,12,52937,52963,12,52993,53019,12,53049,53075,12,53105,53131,12,53161,53187,12,53217,53243,12,53273,53299,12,53329,53355,12,53385,53411,12,53441,53467,12,53497,53523,12,53553,53579,12,53609,53635,12,53665,53691,12,53721,53747,12,53777,53803,12,53833,53859,12,53889,53915,12,53945,53971,12,54001,54027,12,54057,54083,12,54113,54139,12,54169,54195,12,54225,54251,12,54281,54307,12,54337,54363,12,54393,54419,12,54449,54475,12,54505,54531,12,54561,54587,12,54617,54643,12,54673,54699,12,54729,54755,12,54785,54811,12,54841,54867,12,54897,54923,12,54953,54979,12,55009,55035,12,55065,55091,12,55121,55147,12,55177,55203,12,65024,65039,5,65520,65528,4,66422,66426,5,68152,68154,5,69291,69292,5,69633,69633,5,69747,69748,5,69811,69814,5,69826,69826,5,69932,69932,7,70016,70017,5,70079,70080,7,70095,70095,5,70196,70196,5,70367,70367,5,70402,70403,7,70464,70464,5,70487,70487,5,70709,70711,7,70725,70725,7,70833,70834,7,70843,70844,7,70849,70849,7,71090,71093,5,71103,71104,5,71227,71228,7,71339,71339,5,71344,71349,5,71458,71461,5,71727,71735,5,71985,71989,7,71998,71998,5,72002,72002,7,72154,72155,5,72193,72202,5,72251,72254,5,72281,72283,5,72344,72345,5,72766,72766,7,72874,72880,5,72885,72886,5,73023,73029,5,73104,73105,5,73111,73111,5,92912,92916,5,94095,94098,5,113824,113827,4,119142,119142,7,119155,119162,4,119362,119364,5,121476,121476,5,122888,122904,5,123184,123190,5,125252,125258,5,127183,127183,14,127340,127343,14,127377,127386,14,127491,127503,14,127548,127551,14,127744,127756,14,127761,127761,14,127769,127769,14,127773,127774,14,127780,127788,14,127796,127797,14,127820,127823,14,127869,127869,14,127894,127895,14,127902,127903,14,127943,127943,14,127947,127950,14,127972,127972,14,127988,127988,14,127992,127994,14,128009,128011,14,128019,128019,14,128023,128041,14,128064,128064,14,128102,128107,14,128174,128181,14,128238,128238,14,128246,128247,14,128254,128254,14,128264,128264,14,128278,128299,14,128329,128330,14,128348,128359,14,128371,128377,14,128392,128393,14,128401,128404,14,128421,128421,14,128433,128434,14,128450,128452,14,128476,128478,14,128483,128483,14,128495,128495,14,128506,128506,14,128519,128520,14,128528,128528,14,128534,128534,14,128538,128538,14,128540,128542,14,128544,128549,14,128552,128555,14,128557,128557,14,128560,128563,14,128565,128565,14,128567,128576,14,128581,128591,14,128641,128642,14,128646,128646,14,128648,128648,14,128650,128651,14,128653,128653,14,128655,128655,14,128657,128659,14,128661,128661,14,128663,128663,14,128665,128666,14,128674,128674,14,128676,128677,14,128679,128685,14,128690,128690,14,128694,128694,14,128697,128702,14,128704,128704,14,128710,128714,14,128716,128716,14,128720,128720,14,128723,128724,14,128726,128727,14,128733,128735,14,128742,128744,14,128746,128746,14,128749,128751,14,128753,128754,14,128756,128758,14,128761,128761,14,128763,128764,14,128884,128895,14,128992,129003,14,129008,129008,14,129036,129039,14,129114,129119,14,129198,129279,14,129293,129295,14,129305,129310,14,129312,129319,14,129328,129328,14,129331,129338,14,129343,129343,14,129351,129355,14,129357,129359,14,129375,129387,14,129393,129393,14,129395,129398,14,129401,129401,14,129403,129403,14,129408,129412,14,129426,129431,14,129443,129444,14,129451,129453,14,129456,129465,14,129472,129472,14,129475,129482,14,129484,129484,14,129488,129510,14,129536,129647,14,129652,129652,14,129656,129658,14,129661,129663,14,129667,129670,14,129680,129685,14,129705,129708,14,129712,129718,14,129723,129727,14,129731,129733,14,129744,129750,14,129754,129759,14,129768,129775,14,129783,129791,14,917504,917504,4,917506,917535,4,917632,917759,4,918000,921599,4,0,9,4,11,12,4,14,31,4,169,169,14,174,174,14,1155,1159,5,1425,1469,5,1473,1474,5,1479,1479,5,1552,1562,5,1611,1631,5,1750,1756,5,1759,1764,5,1770,1773,5,1809,1809,5,1958,1968,5,2045,2045,5,2075,2083,5,2089,2093,5,2192,2193,1,2250,2273,5,2275,2306,5,2362,2362,5,2364,2364,5,2369,2376,5,2381,2381,5,2385,2391,5,2433,2433,5,2492,2492,5,2495,2496,7,2503,2504,7,2509,2509,5,2530,2531,5,2561,2562,5,2620,2620,5,2625,2626,5,2635,2637,5,2672,2673,5,2689,2690,5,2748,2748,5,2753,2757,5,2761,2761,7,2765,2765,5,2810,2815,5,2818,2819,7,2878,2878,5,2880,2880,7,2887,2888,7,2893,2893,5,2903,2903,5,2946,2946,5,3007,3007,7,3009,3010,7,3018,3020,7,3031,3031,5,3073,3075,7,3132,3132,5,3137,3140,7,3146,3149,5,3170,3171,5,3202,3203,7,3262,3262,7,3264,3265,7,3267,3268,7,3271,3272,7,3276,3277,5,3298,3299,5,3330,3331,7,3390,3390,5,3393,3396,5,3402,3404,7,3406,3406,1,3426,3427,5,3458,3459,7,3535,3535,5,3538,3540,5,3544,3550,7,3570,3571,7,3635,3635,7,3655,3662,5,3763,3763,7,3784,3789,5,3893,3893,5,3897,3897,5,3953,3966,5,3968,3972,5,3981,3991,5,4038,4038,5,4145,4145,7,4153,4154,5,4157,4158,5,4184,4185,5,4209,4212,5,4228,4228,7,4237,4237,5,4352,4447,8,4520,4607,10,5906,5908,5,5938,5939,5,5970,5971,5,6068,6069,5,6071,6077,5,6086,6086,5,6089,6099,5,6155,6157,5,6159,6159,5,6313,6313,5,6435,6438,7,6441,6443,7,6450,6450,5,6457,6459,5,6681,6682,7,6741,6741,7,6743,6743,7,6752,6752,5,6757,6764,5,6771,6780,5,6832,6845,5,6847,6862,5,6916,6916,7,6965,6965,5,6971,6971,7,6973,6977,7,6979,6980,7,7040,7041,5,7073,7073,7,7078,7079,7,7082,7082,7,7142,7142,5,7144,7145,5,7149,7149,5,7151,7153,5,7204,7211,7,7220,7221,7,7376,7378,5,7393,7393,7,7405,7405,5,7415,7415,7,7616,7679,5,8204,8204,5,8206,8207,4,8233,8233,4,8252,8252,14,8288,8292,4,8294,8303,4,8413,8416,5,8418,8420,5,8482,8482,14,8596,8601,14,8986,8987,14,9096,9096,14,9193,9196,14,9199,9199,14,9201,9202,14,9208,9210,14,9642,9643,14,9664,9664,14,9728,9729,14,9732,9732,14,9735,9741,14,9743,9744,14,9746,9746,14,9750,9751,14,9753,9756,14,9758,9759,14,9761,9761,14,9764,9765,14,9767,9769,14,9771,9773,14,9775,9775,14,9784,9785,14,9787,9791,14,9793,9793,14,9795,9799,14,9812,9822,14,9824,9824,14,9827,9827,14,9829,9830,14,9832,9832,14,9851,9851,14,9854,9854,14,9856,9861,14,9874,9874,14,9876,9876,14,9878,9879,14,9881,9881,14,9883,9884,14,9888,9889,14,9895,9895,14,9898,9899,14,9904,9905,14,9917,9918,14,9924,9925,14,9928,9928,14,9934,9934,14,9936,9936,14,9938,9938,14,9940,9940,14,9961,9961,14,9963,9967,14,9970,9971,14,9973,9973,14,9975,9977,14,9979,9980,14,9982,9985,14,9987,9988,14,9992,9996,14,9998,9998,14,10000,10001,14,10004,10004,14,10013,10013,14,10024,10024,14,10052,10052,14,10060,10060,14,10067,10069,14,10083,10083,14,10085,10087,14,10145,10145,14,10175,10175,14,11013,11015,14,11088,11088,14,11503,11505,5,11744,11775,5,12334,12335,5,12349,12349,14,12951,12951,14,42607,42607,5,42612,42621,5,42736,42737,5,43014,43014,5,43043,43044,7,43047,43047,7,43136,43137,7,43204,43205,5,43263,43263,5,43335,43345,5,43360,43388,8,43395,43395,7,43444,43445,7,43450,43451,7,43454,43456,7,43561,43566,5,43569,43570,5,43573,43574,5,43596,43596,5,43644,43644,5,43698,43700,5,43710,43711,5,43755,43755,7,43758,43759,7,43766,43766,5,44005,44005,5,44008,44008,5,44012,44012,7,44032,44032,11,44060,44060,11,44088,44088,11,44116,44116,11,44144,44144,11,44172,44172,11,44200,44200,11,44228,44228,11,44256,44256,11,44284,44284,11,44312,44312,11,44340,44340,11,44368,44368,11,44396,44396,11,44424,44424,11,44452,44452,11,44480,44480,11,44508,44508,11,44536,44536,11,44564,44564,11,44592,44592,11,44620,44620,11,44648,44648,11,44676,44676,11,44704,44704,11,44732,44732,11,44760,44760,11,44788,44788,11,44816,44816,11,44844,44844,11,44872,44872,11,44900,44900,11,44928,44928,11,44956,44956,11,44984,44984,11,45012,45012,11,45040,45040,11,45068,45068,11,45096,45096,11,45124,45124,11,45152,45152,11,45180,45180,11,45208,45208,11,45236,45236,11,45264,45264,11,45292,45292,11,45320,45320,11,45348,45348,11,45376,45376,11,45404,45404,11,45432,45432,11,45460,45460,11,45488,45488,11,45516,45516,11,45544,45544,11,45572,45572,11,45600,45600,11,45628,45628,11,45656,45656,11,45684,45684,11,45712,45712,11,45740,45740,11,45768,45768,11,45796,45796,11,45824,45824,11,45852,45852,11,45880,45880,11,45908,45908,11,45936,45936,11,45964,45964,11,45992,45992,11,46020,46020,11,46048,46048,11,46076,46076,11,46104,46104,11,46132,46132,11,46160,46160,11,46188,46188,11,46216,46216,11,46244,46244,11,46272,46272,11,46300,46300,11,46328,46328,11,46356,46356,11,46384,46384,11,46412,46412,11,46440,46440,11,46468,46468,11,46496,46496,11,46524,46524,11,46552,46552,11,46580,46580,11,46608,46608,11,46636,46636,11,46664,46664,11,46692,46692,11,46720,46720,11,46748,46748,11,46776,46776,11,46804,46804,11,46832,46832,11,46860,46860,11,46888,46888,11,46916,46916,11,46944,46944,11,46972,46972,11,47000,47000,11,47028,47028,11,47056,47056,11,47084,47084,11,47112,47112,11,47140,47140,11,47168,47168,11,47196,47196,11,47224,47224,11,47252,47252,11,47280,47280,11,47308,47308,11,47336,47336,11,47364,47364,11,47392,47392,11,47420,47420,11,47448,47448,11,47476,47476,11,47504,47504,11,47532,47532,11,47560,47560,11,47588,47588,11,47616,47616,11,47644,47644,11,47672,47672,11,47700,47700,11,47728,47728,11,47756,47756,11,47784,47784,11,47812,47812,11,47840,47840,11,47868,47868,11,47896,47896,11,47924,47924,11,47952,47952,11,47980,47980,11,48008,48008,11,48036,48036,11,48064,48064,11,48092,48092,11,48120,48120,11,48148,48148,11,48176,48176,11,48204,48204,11,48232,48232,11,48260,48260,11,48288,48288,11,48316,48316,11,48344,48344,11,48372,48372,11,48400,48400,11,48428,48428,11,48456,48456,11,48484,48484,11,48512,48512,11,48540,48540,11,48568,48568,11,48596,48596,11,48624,48624,11,48652,48652,11,48680,48680,11,48708,48708,11,48736,48736,11,48764,48764,11,48792,48792,11,48820,48820,11,48848,48848,11,48876,48876,11,48904,48904,11,48932,48932,11,48960,48960,11,48988,48988,11,49016,49016,11,49044,49044,11,49072,49072,11,49100,49100,11,49128,49128,11,49156,49156,11,49184,49184,11,49212,49212,11,49240,49240,11,49268,49268,11,49296,49296,11,49324,49324,11,49352,49352,11,49380,49380,11,49408,49408,11,49436,49436,11,49464,49464,11,49492,49492,11,49520,49520,11,49548,49548,11,49576,49576,11,49604,49604,11,49632,49632,11,49660,49660,11,49688,49688,11,49716,49716,11,49744,49744,11,49772,49772,11,49800,49800,11,49828,49828,11,49856,49856,11,49884,49884,11,49912,49912,11,49940,49940,11,49968,49968,11,49996,49996,11,50024,50024,11,50052,50052,11,50080,50080,11,50108,50108,11,50136,50136,11,50164,50164,11,50192,50192,11,50220,50220,11,50248,50248,11,50276,50276,11,50304,50304,11,50332,50332,11,50360,50360,11,50388,50388,11,50416,50416,11,50444,50444,11,50472,50472,11,50500,50500,11,50528,50528,11,50556,50556,11,50584,50584,11,50612,50612,11,50640,50640,11,50668,50668,11,50696,50696,11,50724,50724,11,50752,50752,11,50780,50780,11,50808,50808,11,50836,50836,11,50864,50864,11,50892,50892,11,50920,50920,11,50948,50948,11,50976,50976,11,51004,51004,11,51032,51032,11,51060,51060,11,51088,51088,11,51116,51116,11,51144,51144,11,51172,51172,11,51200,51200,11,51228,51228,11,51256,51256,11,51284,51284,11,51312,51312,11,51340,51340,11,51368,51368,11,51396,51396,11,51424,51424,11,51452,51452,11,51480,51480,11,51508,51508,11,51536,51536,11,51564,51564,11,51592,51592,11,51620,51620,11,51648,51648,11,51676,51676,11,51704,51704,11,51732,51732,11,51760,51760,11,51788,51788,11,51816,51816,11,51844,51844,11,51872,51872,11,51900,51900,11,51928,51928,11,51956,51956,11,51984,51984,11,52012,52012,11,52040,52040,11,52068,52068,11,52096,52096,11,52124,52124,11,52152,52152,11,52180,52180,11,52208,52208,11,52236,52236,11,52264,52264,11,52292,52292,11,52320,52320,11,52348,52348,11,52376,52376,11,52404,52404,11,52432,52432,11,52460,52460,11,52488,52488,11,52516,52516,11,52544,52544,11,52572,52572,11,52600,52600,11,52628,52628,11,52656,52656,11,52684,52684,11,52712,52712,11,52740,52740,11,52768,52768,11,52796,52796,11,52824,52824,11,52852,52852,11,52880,52880,11,52908,52908,11,52936,52936,11,52964,52964,11,52992,52992,11,53020,53020,11,53048,53048,11,53076,53076,11,53104,53104,11,53132,53132,11,53160,53160,11,53188,53188,11,53216,53216,11,53244,53244,11,53272,53272,11,53300,53300,11,53328,53328,11,53356,53356,11,53384,53384,11,53412,53412,11,53440,53440,11,53468,53468,11,53496,53496,11,53524,53524,11,53552,53552,11,53580,53580,11,53608,53608,11,53636,53636,11,53664,53664,11,53692,53692,11,53720,53720,11,53748,53748,11,53776,53776,11,53804,53804,11,53832,53832,11,53860,53860,11,53888,53888,11,53916,53916,11,53944,53944,11,53972,53972,11,54000,54000,11,54028,54028,11,54056,54056,11,54084,54084,11,54112,54112,11,54140,54140,11,54168,54168,11,54196,54196,11,54224,54224,11,54252,54252,11,54280,54280,11,54308,54308,11,54336,54336,11,54364,54364,11,54392,54392,11,54420,54420,11,54448,54448,11,54476,54476,11,54504,54504,11,54532,54532,11,54560,54560,11,54588,54588,11,54616,54616,11,54644,54644,11,54672,54672,11,54700,54700,11,54728,54728,11,54756,54756,11,54784,54784,11,54812,54812,11,54840,54840,11,54868,54868,11,54896,54896,11,54924,54924,11,54952,54952,11,54980,54980,11,55008,55008,11,55036,55036,11,55064,55064,11,55092,55092,11,55120,55120,11,55148,55148,11,55176,55176,11,55216,55238,9,64286,64286,5,65056,65071,5,65438,65439,5,65529,65531,4,66272,66272,5,68097,68099,5,68108,68111,5,68159,68159,5,68900,68903,5,69446,69456,5,69632,69632,7,69634,69634,7,69744,69744,5,69759,69761,5,69808,69810,7,69815,69816,7,69821,69821,1,69837,69837,1,69927,69931,5,69933,69940,5,70003,70003,5,70018,70018,7,70070,70078,5,70082,70083,1,70094,70094,7,70188,70190,7,70194,70195,7,70197,70197,7,70206,70206,5,70368,70370,7,70400,70401,5,70459,70460,5,70463,70463,7,70465,70468,7,70475,70477,7,70498,70499,7,70512,70516,5,70712,70719,5,70722,70724,5,70726,70726,5,70832,70832,5,70835,70840,5,70842,70842,5,70845,70845,5,70847,70848,5,70850,70851,5,71088,71089,7,71096,71099,7,71102,71102,7,71132,71133,5,71219,71226,5,71229,71229,5,71231,71232,5,71340,71340,7,71342,71343,7,71350,71350,7,71453,71455,5,71462,71462,7,71724,71726,7,71736,71736,7,71984,71984,5,71991,71992,7,71997,71997,7,71999,71999,1,72001,72001,1,72003,72003,5,72148,72151,5,72156,72159,7,72164,72164,7,72243,72248,5,72250,72250,1,72263,72263,5,72279,72280,7,72324,72329,1,72343,72343,7,72751,72751,7,72760,72765,5,72767,72767,5,72873,72873,7,72881,72881,7,72884,72884,7,73009,73014,5,73020,73021,5,73030,73030,1,73098,73102,7,73107,73108,7,73110,73110,7,73459,73460,5,78896,78904,4,92976,92982,5,94033,94087,7,94180,94180,5,113821,113822,5,118528,118573,5,119141,119141,5,119143,119145,5,119150,119154,5,119163,119170,5,119210,119213,5,121344,121398,5,121461,121461,5,121499,121503,5,122880,122886,5,122907,122913,5,122918,122922,5,123566,123566,5,125136,125142,5,126976,126979,14,126981,127182,14,127184,127231,14,127279,127279,14,127344,127345,14,127374,127374,14,127405,127461,14,127489,127490,14,127514,127514,14,127538,127546,14,127561,127567,14,127570,127743,14,127757,127758,14,127760,127760,14,127762,127762,14,127766,127768,14,127770,127770,14,127772,127772,14,127775,127776,14,127778,127779,14,127789,127791,14,127794,127795,14,127798,127798,14,127819,127819,14,127824,127824,14,127868,127868,14,127870,127871,14,127892,127893,14,127896,127896,14,127900,127901,14,127904,127940,14,127942,127942,14,127944,127944,14,127946,127946,14,127951,127955,14,127968,127971,14,127973,127984,14,127987,127987,14,127989,127989,14,127991,127991,14,127995,127999,5,128008,128008,14,128012,128014,14,128017,128018,14,128020,128020,14,128022,128022,14,128042,128042,14,128063,128063,14,128065,128065,14,128101,128101,14,128108,128109,14,128173,128173,14,128182,128183,14,128236,128237,14,128239,128239,14,128245,128245,14,128248,128248,14,128253,128253,14,128255,128258,14,128260,128263,14,128265,128265,14,128277,128277,14,128300,128301,14,128326,128328,14,128331,128334,14,128336,128347,14,128360,128366,14,128369,128370,14,128378,128378,14,128391,128391,14,128394,128397,14,128400,128400,14,128405,128406,14,128420,128420,14,128422,128423,14,128425,128432,14,128435,128443,14,128445,128449,14,128453,128464,14,128468,128475,14,128479,128480,14,128482,128482,14,128484,128487,14,128489,128494,14,128496,128498,14,128500,128505,14,128507,128511,14,128513,128518,14,128521,128525,14,128527,128527,14,128529,128529,14,128533,128533,14,128535,128535,14,128537,128537,14]")}getGraphemeBreakType(e){if(e<32)return 10===e?3:13===e?2:4;if(e<127)return 0;const t=this._data,i=t.length/3;let s=1;for(;s<=i;)if(et[3*s+1]))return t[3*s+2];s=2*s+1}return 0}}function se(e,t){if(0===e)return 0;const i=function(e,t){const i=new U(t,e);let s=i.prevCodePoint();for(;ne(s)||65039===s||8419===s;){if(0===i.offset)return;s=i.prevCodePoint()}if(!Q(s))return;let n=i.offset;if(n>0){8205===i.prevCodePoint()&&(n=i.offset)}return n}(e,t);if(void 0!==i)return i;const s=new U(t,e);return s.prevCodePoint(),s.offset}function ne(e){return 127995<=e&&e<=127999}const re="\xa0";class oe{static{this.ambiguousCharacterData=new n.d((()=>JSON.parse('{"_common":[8232,32,8233,32,5760,32,8192,32,8193,32,8194,32,8195,32,8196,32,8197,32,8198,32,8200,32,8201,32,8202,32,8287,32,8199,32,8239,32,2042,95,65101,95,65102,95,65103,95,8208,45,8209,45,8210,45,65112,45,1748,45,8259,45,727,45,8722,45,10134,45,11450,45,1549,44,1643,44,8218,44,184,44,42233,44,894,59,2307,58,2691,58,1417,58,1795,58,1796,58,5868,58,65072,58,6147,58,6153,58,8282,58,1475,58,760,58,42889,58,8758,58,720,58,42237,58,451,33,11601,33,660,63,577,63,2429,63,5038,63,42731,63,119149,46,8228,46,1793,46,1794,46,42510,46,68176,46,1632,46,1776,46,42232,46,1373,96,65287,96,8219,96,8242,96,1370,96,1523,96,8175,96,65344,96,900,96,8189,96,8125,96,8127,96,8190,96,697,96,884,96,712,96,714,96,715,96,756,96,699,96,701,96,700,96,702,96,42892,96,1497,96,2036,96,2037,96,5194,96,5836,96,94033,96,94034,96,65339,91,10088,40,10098,40,12308,40,64830,40,65341,93,10089,41,10099,41,12309,41,64831,41,10100,123,119060,123,10101,125,65342,94,8270,42,1645,42,8727,42,66335,42,5941,47,8257,47,8725,47,8260,47,9585,47,10187,47,10744,47,119354,47,12755,47,12339,47,11462,47,20031,47,12035,47,65340,92,65128,92,8726,92,10189,92,10741,92,10745,92,119311,92,119355,92,12756,92,20022,92,12034,92,42872,38,708,94,710,94,5869,43,10133,43,66203,43,8249,60,10094,60,706,60,119350,60,5176,60,5810,60,5120,61,11840,61,12448,61,42239,61,8250,62,10095,62,707,62,119351,62,5171,62,94015,62,8275,126,732,126,8128,126,8764,126,65372,124,65293,45,120784,50,120794,50,120804,50,120814,50,120824,50,130034,50,42842,50,423,50,1000,50,42564,50,5311,50,42735,50,119302,51,120785,51,120795,51,120805,51,120815,51,120825,51,130035,51,42923,51,540,51,439,51,42858,51,11468,51,1248,51,94011,51,71882,51,120786,52,120796,52,120806,52,120816,52,120826,52,130036,52,5070,52,71855,52,120787,53,120797,53,120807,53,120817,53,120827,53,130037,53,444,53,71867,53,120788,54,120798,54,120808,54,120818,54,120828,54,130038,54,11474,54,5102,54,71893,54,119314,55,120789,55,120799,55,120809,55,120819,55,120829,55,130039,55,66770,55,71878,55,2819,56,2538,56,2666,56,125131,56,120790,56,120800,56,120810,56,120820,56,120830,56,130040,56,547,56,546,56,66330,56,2663,57,2920,57,2541,57,3437,57,120791,57,120801,57,120811,57,120821,57,120831,57,130041,57,42862,57,11466,57,71884,57,71852,57,71894,57,9082,97,65345,97,119834,97,119886,97,119938,97,119990,97,120042,97,120094,97,120146,97,120198,97,120250,97,120302,97,120354,97,120406,97,120458,97,593,97,945,97,120514,97,120572,97,120630,97,120688,97,120746,97,65313,65,119808,65,119860,65,119912,65,119964,65,120016,65,120068,65,120120,65,120172,65,120224,65,120276,65,120328,65,120380,65,120432,65,913,65,120488,65,120546,65,120604,65,120662,65,120720,65,5034,65,5573,65,42222,65,94016,65,66208,65,119835,98,119887,98,119939,98,119991,98,120043,98,120095,98,120147,98,120199,98,120251,98,120303,98,120355,98,120407,98,120459,98,388,98,5071,98,5234,98,5551,98,65314,66,8492,66,119809,66,119861,66,119913,66,120017,66,120069,66,120121,66,120173,66,120225,66,120277,66,120329,66,120381,66,120433,66,42932,66,914,66,120489,66,120547,66,120605,66,120663,66,120721,66,5108,66,5623,66,42192,66,66178,66,66209,66,66305,66,65347,99,8573,99,119836,99,119888,99,119940,99,119992,99,120044,99,120096,99,120148,99,120200,99,120252,99,120304,99,120356,99,120408,99,120460,99,7428,99,1010,99,11429,99,43951,99,66621,99,128844,67,71922,67,71913,67,65315,67,8557,67,8450,67,8493,67,119810,67,119862,67,119914,67,119966,67,120018,67,120174,67,120226,67,120278,67,120330,67,120382,67,120434,67,1017,67,11428,67,5087,67,42202,67,66210,67,66306,67,66581,67,66844,67,8574,100,8518,100,119837,100,119889,100,119941,100,119993,100,120045,100,120097,100,120149,100,120201,100,120253,100,120305,100,120357,100,120409,100,120461,100,1281,100,5095,100,5231,100,42194,100,8558,68,8517,68,119811,68,119863,68,119915,68,119967,68,120019,68,120071,68,120123,68,120175,68,120227,68,120279,68,120331,68,120383,68,120435,68,5024,68,5598,68,5610,68,42195,68,8494,101,65349,101,8495,101,8519,101,119838,101,119890,101,119942,101,120046,101,120098,101,120150,101,120202,101,120254,101,120306,101,120358,101,120410,101,120462,101,43826,101,1213,101,8959,69,65317,69,8496,69,119812,69,119864,69,119916,69,120020,69,120072,69,120124,69,120176,69,120228,69,120280,69,120332,69,120384,69,120436,69,917,69,120492,69,120550,69,120608,69,120666,69,120724,69,11577,69,5036,69,42224,69,71846,69,71854,69,66182,69,119839,102,119891,102,119943,102,119995,102,120047,102,120099,102,120151,102,120203,102,120255,102,120307,102,120359,102,120411,102,120463,102,43829,102,42905,102,383,102,7837,102,1412,102,119315,70,8497,70,119813,70,119865,70,119917,70,120021,70,120073,70,120125,70,120177,70,120229,70,120281,70,120333,70,120385,70,120437,70,42904,70,988,70,120778,70,5556,70,42205,70,71874,70,71842,70,66183,70,66213,70,66853,70,65351,103,8458,103,119840,103,119892,103,119944,103,120048,103,120100,103,120152,103,120204,103,120256,103,120308,103,120360,103,120412,103,120464,103,609,103,7555,103,397,103,1409,103,119814,71,119866,71,119918,71,119970,71,120022,71,120074,71,120126,71,120178,71,120230,71,120282,71,120334,71,120386,71,120438,71,1292,71,5056,71,5107,71,42198,71,65352,104,8462,104,119841,104,119945,104,119997,104,120049,104,120101,104,120153,104,120205,104,120257,104,120309,104,120361,104,120413,104,120465,104,1211,104,1392,104,5058,104,65320,72,8459,72,8460,72,8461,72,119815,72,119867,72,119919,72,120023,72,120179,72,120231,72,120283,72,120335,72,120387,72,120439,72,919,72,120494,72,120552,72,120610,72,120668,72,120726,72,11406,72,5051,72,5500,72,42215,72,66255,72,731,105,9075,105,65353,105,8560,105,8505,105,8520,105,119842,105,119894,105,119946,105,119998,105,120050,105,120102,105,120154,105,120206,105,120258,105,120310,105,120362,105,120414,105,120466,105,120484,105,618,105,617,105,953,105,8126,105,890,105,120522,105,120580,105,120638,105,120696,105,120754,105,1110,105,42567,105,1231,105,43893,105,5029,105,71875,105,65354,106,8521,106,119843,106,119895,106,119947,106,119999,106,120051,106,120103,106,120155,106,120207,106,120259,106,120311,106,120363,106,120415,106,120467,106,1011,106,1112,106,65322,74,119817,74,119869,74,119921,74,119973,74,120025,74,120077,74,120129,74,120181,74,120233,74,120285,74,120337,74,120389,74,120441,74,42930,74,895,74,1032,74,5035,74,5261,74,42201,74,119844,107,119896,107,119948,107,120000,107,120052,107,120104,107,120156,107,120208,107,120260,107,120312,107,120364,107,120416,107,120468,107,8490,75,65323,75,119818,75,119870,75,119922,75,119974,75,120026,75,120078,75,120130,75,120182,75,120234,75,120286,75,120338,75,120390,75,120442,75,922,75,120497,75,120555,75,120613,75,120671,75,120729,75,11412,75,5094,75,5845,75,42199,75,66840,75,1472,108,8739,73,9213,73,65512,73,1633,108,1777,73,66336,108,125127,108,120783,73,120793,73,120803,73,120813,73,120823,73,130033,73,65321,73,8544,73,8464,73,8465,73,119816,73,119868,73,119920,73,120024,73,120128,73,120180,73,120232,73,120284,73,120336,73,120388,73,120440,73,65356,108,8572,73,8467,108,119845,108,119897,108,119949,108,120001,108,120053,108,120105,73,120157,73,120209,73,120261,73,120313,73,120365,73,120417,73,120469,73,448,73,120496,73,120554,73,120612,73,120670,73,120728,73,11410,73,1030,73,1216,73,1493,108,1503,108,1575,108,126464,108,126592,108,65166,108,65165,108,1994,108,11599,73,5825,73,42226,73,93992,73,66186,124,66313,124,119338,76,8556,76,8466,76,119819,76,119871,76,119923,76,120027,76,120079,76,120131,76,120183,76,120235,76,120287,76,120339,76,120391,76,120443,76,11472,76,5086,76,5290,76,42209,76,93974,76,71843,76,71858,76,66587,76,66854,76,65325,77,8559,77,8499,77,119820,77,119872,77,119924,77,120028,77,120080,77,120132,77,120184,77,120236,77,120288,77,120340,77,120392,77,120444,77,924,77,120499,77,120557,77,120615,77,120673,77,120731,77,1018,77,11416,77,5047,77,5616,77,5846,77,42207,77,66224,77,66321,77,119847,110,119899,110,119951,110,120003,110,120055,110,120107,110,120159,110,120211,110,120263,110,120315,110,120367,110,120419,110,120471,110,1400,110,1404,110,65326,78,8469,78,119821,78,119873,78,119925,78,119977,78,120029,78,120081,78,120185,78,120237,78,120289,78,120341,78,120393,78,120445,78,925,78,120500,78,120558,78,120616,78,120674,78,120732,78,11418,78,42208,78,66835,78,3074,111,3202,111,3330,111,3458,111,2406,111,2662,111,2790,111,3046,111,3174,111,3302,111,3430,111,3664,111,3792,111,4160,111,1637,111,1781,111,65359,111,8500,111,119848,111,119900,111,119952,111,120056,111,120108,111,120160,111,120212,111,120264,111,120316,111,120368,111,120420,111,120472,111,7439,111,7441,111,43837,111,959,111,120528,111,120586,111,120644,111,120702,111,120760,111,963,111,120532,111,120590,111,120648,111,120706,111,120764,111,11423,111,4351,111,1413,111,1505,111,1607,111,126500,111,126564,111,126596,111,65259,111,65260,111,65258,111,65257,111,1726,111,64428,111,64429,111,64427,111,64426,111,1729,111,64424,111,64425,111,64423,111,64422,111,1749,111,3360,111,4125,111,66794,111,71880,111,71895,111,66604,111,1984,79,2534,79,2918,79,12295,79,70864,79,71904,79,120782,79,120792,79,120802,79,120812,79,120822,79,130032,79,65327,79,119822,79,119874,79,119926,79,119978,79,120030,79,120082,79,120134,79,120186,79,120238,79,120290,79,120342,79,120394,79,120446,79,927,79,120502,79,120560,79,120618,79,120676,79,120734,79,11422,79,1365,79,11604,79,4816,79,2848,79,66754,79,42227,79,71861,79,66194,79,66219,79,66564,79,66838,79,9076,112,65360,112,119849,112,119901,112,119953,112,120005,112,120057,112,120109,112,120161,112,120213,112,120265,112,120317,112,120369,112,120421,112,120473,112,961,112,120530,112,120544,112,120588,112,120602,112,120646,112,120660,112,120704,112,120718,112,120762,112,120776,112,11427,112,65328,80,8473,80,119823,80,119875,80,119927,80,119979,80,120031,80,120083,80,120187,80,120239,80,120291,80,120343,80,120395,80,120447,80,929,80,120504,80,120562,80,120620,80,120678,80,120736,80,11426,80,5090,80,5229,80,42193,80,66197,80,119850,113,119902,113,119954,113,120006,113,120058,113,120110,113,120162,113,120214,113,120266,113,120318,113,120370,113,120422,113,120474,113,1307,113,1379,113,1382,113,8474,81,119824,81,119876,81,119928,81,119980,81,120032,81,120084,81,120188,81,120240,81,120292,81,120344,81,120396,81,120448,81,11605,81,119851,114,119903,114,119955,114,120007,114,120059,114,120111,114,120163,114,120215,114,120267,114,120319,114,120371,114,120423,114,120475,114,43847,114,43848,114,7462,114,11397,114,43905,114,119318,82,8475,82,8476,82,8477,82,119825,82,119877,82,119929,82,120033,82,120189,82,120241,82,120293,82,120345,82,120397,82,120449,82,422,82,5025,82,5074,82,66740,82,5511,82,42211,82,94005,82,65363,115,119852,115,119904,115,119956,115,120008,115,120060,115,120112,115,120164,115,120216,115,120268,115,120320,115,120372,115,120424,115,120476,115,42801,115,445,115,1109,115,43946,115,71873,115,66632,115,65331,83,119826,83,119878,83,119930,83,119982,83,120034,83,120086,83,120138,83,120190,83,120242,83,120294,83,120346,83,120398,83,120450,83,1029,83,1359,83,5077,83,5082,83,42210,83,94010,83,66198,83,66592,83,119853,116,119905,116,119957,116,120009,116,120061,116,120113,116,120165,116,120217,116,120269,116,120321,116,120373,116,120425,116,120477,116,8868,84,10201,84,128872,84,65332,84,119827,84,119879,84,119931,84,119983,84,120035,84,120087,84,120139,84,120191,84,120243,84,120295,84,120347,84,120399,84,120451,84,932,84,120507,84,120565,84,120623,84,120681,84,120739,84,11430,84,5026,84,42196,84,93962,84,71868,84,66199,84,66225,84,66325,84,119854,117,119906,117,119958,117,120010,117,120062,117,120114,117,120166,117,120218,117,120270,117,120322,117,120374,117,120426,117,120478,117,42911,117,7452,117,43854,117,43858,117,651,117,965,117,120534,117,120592,117,120650,117,120708,117,120766,117,1405,117,66806,117,71896,117,8746,85,8899,85,119828,85,119880,85,119932,85,119984,85,120036,85,120088,85,120140,85,120192,85,120244,85,120296,85,120348,85,120400,85,120452,85,1357,85,4608,85,66766,85,5196,85,42228,85,94018,85,71864,85,8744,118,8897,118,65366,118,8564,118,119855,118,119907,118,119959,118,120011,118,120063,118,120115,118,120167,118,120219,118,120271,118,120323,118,120375,118,120427,118,120479,118,7456,118,957,118,120526,118,120584,118,120642,118,120700,118,120758,118,1141,118,1496,118,71430,118,43945,118,71872,118,119309,86,1639,86,1783,86,8548,86,119829,86,119881,86,119933,86,119985,86,120037,86,120089,86,120141,86,120193,86,120245,86,120297,86,120349,86,120401,86,120453,86,1140,86,11576,86,5081,86,5167,86,42719,86,42214,86,93960,86,71840,86,66845,86,623,119,119856,119,119908,119,119960,119,120012,119,120064,119,120116,119,120168,119,120220,119,120272,119,120324,119,120376,119,120428,119,120480,119,7457,119,1121,119,1309,119,1377,119,71434,119,71438,119,71439,119,43907,119,71919,87,71910,87,119830,87,119882,87,119934,87,119986,87,120038,87,120090,87,120142,87,120194,87,120246,87,120298,87,120350,87,120402,87,120454,87,1308,87,5043,87,5076,87,42218,87,5742,120,10539,120,10540,120,10799,120,65368,120,8569,120,119857,120,119909,120,119961,120,120013,120,120065,120,120117,120,120169,120,120221,120,120273,120,120325,120,120377,120,120429,120,120481,120,5441,120,5501,120,5741,88,9587,88,66338,88,71916,88,65336,88,8553,88,119831,88,119883,88,119935,88,119987,88,120039,88,120091,88,120143,88,120195,88,120247,88,120299,88,120351,88,120403,88,120455,88,42931,88,935,88,120510,88,120568,88,120626,88,120684,88,120742,88,11436,88,11613,88,5815,88,42219,88,66192,88,66228,88,66327,88,66855,88,611,121,7564,121,65369,121,119858,121,119910,121,119962,121,120014,121,120066,121,120118,121,120170,121,120222,121,120274,121,120326,121,120378,121,120430,121,120482,121,655,121,7935,121,43866,121,947,121,8509,121,120516,121,120574,121,120632,121,120690,121,120748,121,1199,121,4327,121,71900,121,65337,89,119832,89,119884,89,119936,89,119988,89,120040,89,120092,89,120144,89,120196,89,120248,89,120300,89,120352,89,120404,89,120456,89,933,89,978,89,120508,89,120566,89,120624,89,120682,89,120740,89,11432,89,1198,89,5033,89,5053,89,42220,89,94019,89,71844,89,66226,89,119859,122,119911,122,119963,122,120015,122,120067,122,120119,122,120171,122,120223,122,120275,122,120327,122,120379,122,120431,122,120483,122,7458,122,43923,122,71876,122,66293,90,71909,90,65338,90,8484,90,8488,90,119833,90,119885,90,119937,90,119989,90,120041,90,120197,90,120249,90,120301,90,120353,90,120405,90,120457,90,918,90,120493,90,120551,90,120609,90,120667,90,120725,90,5059,90,42204,90,71849,90,65282,34,65284,36,65285,37,65286,38,65290,42,65291,43,65294,46,65295,47,65296,48,65297,49,65298,50,65299,51,65300,52,65301,53,65302,54,65303,55,65304,56,65305,57,65308,60,65309,61,65310,62,65312,64,65316,68,65318,70,65319,71,65324,76,65329,81,65330,82,65333,85,65334,86,65335,87,65343,95,65346,98,65348,100,65350,102,65355,107,65357,109,65358,110,65361,113,65362,114,65364,116,65365,117,65367,119,65370,122,65371,123,65373,125,119846,109],"_default":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"cs":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"de":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"es":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"fr":[65374,126,65306,58,65281,33,8216,96,8245,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"it":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ja":[8211,45,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65292,44,65307,59],"ko":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pl":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pt-BR":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"qps-ploc":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ru":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,305,105,921,73,1009,112,215,120,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"tr":[160,32,8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"zh-hans":[65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65288,40,65289,41],"zh-hant":[8211,45,65374,126,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65307,59]}')))}static{this.cache=new s.o5({getCacheKey:JSON.stringify},(e=>{function t(e){const t=new Map;for(let i=0;i!e.startsWith("_")&&e in s));0===r.length&&(r=["_default"]);for(const a of r){n=i(n,t(s[a]))}const o=function(e,t){const i=new Map(e);for(const[s,n]of t)i.set(s,n);return i}(t(s._common),n);return new oe(o)}))}static getInstance(e){return oe.cache.get(Array.from(e))}static{this._locales=new n.d((()=>Object.keys(oe.ambiguousCharacterData.value).filter((e=>!e.startsWith("_")))))}static getLocales(){return oe._locales.value}constructor(e){this.confusableDictionary=e}isAmbiguous(e){return this.confusableDictionary.has(e)}getPrimaryConfusable(e){return this.confusableDictionary.get(e)}getConfusableCodePoints(){return new Set(this.confusableDictionary.keys())}}class ae{static getRawData(){return JSON.parse("[9,10,11,12,13,32,127,160,173,847,1564,4447,4448,6068,6069,6155,6156,6157,6158,7355,7356,8192,8193,8194,8195,8196,8197,8198,8199,8200,8201,8202,8203,8204,8205,8206,8207,8234,8235,8236,8237,8238,8239,8287,8288,8289,8290,8291,8292,8293,8294,8295,8296,8297,8298,8299,8300,8301,8302,8303,10240,12288,12644,65024,65025,65026,65027,65028,65029,65030,65031,65032,65033,65034,65035,65036,65037,65038,65039,65279,65440,65520,65521,65522,65523,65524,65525,65526,65527,65528,65532,78844,119155,119156,119157,119158,119159,119160,119161,119162,917504,917505,917506,917507,917508,917509,917510,917511,917512,917513,917514,917515,917516,917517,917518,917519,917520,917521,917522,917523,917524,917525,917526,917527,917528,917529,917530,917531,917532,917533,917534,917535,917536,917537,917538,917539,917540,917541,917542,917543,917544,917545,917546,917547,917548,917549,917550,917551,917552,917553,917554,917555,917556,917557,917558,917559,917560,917561,917562,917563,917564,917565,917566,917567,917568,917569,917570,917571,917572,917573,917574,917575,917576,917577,917578,917579,917580,917581,917582,917583,917584,917585,917586,917587,917588,917589,917590,917591,917592,917593,917594,917595,917596,917597,917598,917599,917600,917601,917602,917603,917604,917605,917606,917607,917608,917609,917610,917611,917612,917613,917614,917615,917616,917617,917618,917619,917620,917621,917622,917623,917624,917625,917626,917627,917628,917629,917630,917631,917760,917761,917762,917763,917764,917765,917766,917767,917768,917769,917770,917771,917772,917773,917774,917775,917776,917777,917778,917779,917780,917781,917782,917783,917784,917785,917786,917787,917788,917789,917790,917791,917792,917793,917794,917795,917796,917797,917798,917799,917800,917801,917802,917803,917804,917805,917806,917807,917808,917809,917810,917811,917812,917813,917814,917815,917816,917817,917818,917819,917820,917821,917822,917823,917824,917825,917826,917827,917828,917829,917830,917831,917832,917833,917834,917835,917836,917837,917838,917839,917840,917841,917842,917843,917844,917845,917846,917847,917848,917849,917850,917851,917852,917853,917854,917855,917856,917857,917858,917859,917860,917861,917862,917863,917864,917865,917866,917867,917868,917869,917870,917871,917872,917873,917874,917875,917876,917877,917878,917879,917880,917881,917882,917883,917884,917885,917886,917887,917888,917889,917890,917891,917892,917893,917894,917895,917896,917897,917898,917899,917900,917901,917902,917903,917904,917905,917906,917907,917908,917909,917910,917911,917912,917913,917914,917915,917916,917917,917918,917919,917920,917921,917922,917923,917924,917925,917926,917927,917928,917929,917930,917931,917932,917933,917934,917935,917936,917937,917938,917939,917940,917941,917942,917943,917944,917945,917946,917947,917948,917949,917950,917951,917952,917953,917954,917955,917956,917957,917958,917959,917960,917961,917962,917963,917964,917965,917966,917967,917968,917969,917970,917971,917972,917973,917974,917975,917976,917977,917978,917979,917980,917981,917982,917983,917984,917985,917986,917987,917988,917989,917990,917991,917992,917993,917994,917995,917996,917997,917998,917999]")}static{this._data=void 0}static getData(){return this._data||(this._data=new Set(ae.getRawData())),this._data}static isInvisibleCharacter(e){return ae.getData().has(e)}static get codePoints(){return ae.getData()}}},91581:(e,t,i)=>{"use strict";i.d(t,{mJ:()=>E,x8:()=>v});var s=i(8597),n=i(56245),r=i(27661),o=i(11799),a=i(11007),c=i(48196),l=i(42904),h=i(31295),d=i(17390),u=i(41234);class g{constructor(e,t=0,i=e.length,s=t-1){this.items=e,this.start=t,this.end=i,this.index=s}current(){return this.index===this.start-1||this.index===this.end?null:this.items[this.index]}next(){return this.index=Math.min(this.index+1,this.end),this.current()}previous(){return this.index=Math.max(this.index-1,this.start-1),this.current()}first(){return this.index=this.start,this.current()}last(){return this.index=this.end-1,this.current()}}class p{constructor(e=[],t=10){this._initialize(e),this._limit=t,this._onChange()}getHistory(){return this._elements}add(e){this._history.delete(e),this._history.add(e),this._onChange()}next(){return this._navigator.next()}previous(){return 0!==this._currentPosition()?this._navigator.previous():null}current(){return this._navigator.current()}first(){return this._navigator.first()}last(){return this._navigator.last()}isLast(){return this._currentPosition()>=this._elements.length-1}isNowhere(){return null===this._navigator.current()}has(e){return this._history.has(e)}_onChange(){this._reduceToLimit();const e=this._elements;this._navigator=new g(e,0,e.length,e.length)}_reduceToLimit(){const e=this._elements;e.length>this._limit&&this._initialize(e.slice(e.length-this._limit))}_currentPosition(){const e=this._navigator.current();return e?this._elements.indexOf(e):-1}_initialize(e){this._history=new Set;for(const t of e)this._history.add(t)}get _elements(){const e=[];return this._history.forEach((t=>e.push(t))),e}}var m=i(10146),f=i(78209);const _=s.$,v={inputBackground:"#3C3C3C",inputForeground:"#CCCCCC",inputValidationInfoBorder:"#55AAFF",inputValidationInfoBackground:"#063B49",inputValidationWarningBorder:"#B89500",inputValidationWarningBackground:"#352A05",inputValidationErrorBorder:"#BE1100",inputValidationErrorBackground:"#5A1D1D",inputBorder:void 0,inputValidationErrorForeground:void 0,inputValidationInfoForeground:void 0,inputValidationWarningForeground:void 0};class C extends d.x{constructor(e,t,i){super(),this.state="idle",this.maxHeight=Number.POSITIVE_INFINITY,this._onDidChange=this._register(new u.vl),this.onDidChange=this._onDidChange.event,this._onDidHeightChange=this._register(new u.vl),this.onDidHeightChange=this._onDidHeightChange.event,this.contextViewProvider=t,this.options=i,this.message=null,this.placeholder=this.options.placeholder||"",this.tooltip=this.options.tooltip??(this.placeholder||""),this.ariaLabel=this.options.ariaLabel||"",this.options.validationOptions&&(this.validation=this.options.validationOptions.validation),this.element=s.BC(e,_(".monaco-inputbox.idle"));const r=this.options.flexibleHeight?"textarea":"input",a=s.BC(this.element,_(".ibwrapper"));if(this.input=s.BC(a,_(r+".input.empty")),this.input.setAttribute("autocorrect","off"),this.input.setAttribute("autocapitalize","off"),this.input.setAttribute("spellcheck","false"),this.onfocus(this.input,(()=>this.element.classList.add("synthetic-focus"))),this.onblur(this.input,(()=>this.element.classList.remove("synthetic-focus"))),this.options.flexibleHeight){this.maxHeight="number"===typeof this.options.flexibleMaxHeight?this.options.flexibleMaxHeight:Number.POSITIVE_INFINITY,this.mirror=s.BC(a,_("div.mirror")),this.mirror.innerText="\xa0",this.scrollableElement=new h.Se(this.element,{vertical:1}),this.options.flexibleWidth&&(this.input.setAttribute("wrap","off"),this.mirror.style.whiteSpace="pre",this.mirror.style.wordWrap="initial"),s.BC(e,this.scrollableElement.getDomNode()),this._register(this.scrollableElement),this._register(this.scrollableElement.onScroll((e=>this.input.scrollTop=e.scrollTop)));const t=this._register(new n.f(e.ownerDocument,"selectionchange")),i=u.Jh.filter(t.event,(()=>{const t=e.ownerDocument.getSelection();return t?.anchorNode===a}));this._register(i(this.updateScrollDimensions,this)),this._register(this.onDidHeightChange(this.updateScrollDimensions,this))}else this.input.type=this.options.type||"text",this.input.setAttribute("wrap","off");this.ariaLabel&&this.input.setAttribute("aria-label",this.ariaLabel),this.placeholder&&!this.options.showPlaceholderOnFocus&&this.setPlaceHolder(this.placeholder),this.tooltip&&this.setTooltip(this.tooltip),this.oninput(this.input,(()=>this.onValueChange())),this.onblur(this.input,(()=>this.onBlur())),this.onfocus(this.input,(()=>this.onFocus())),this._register(this.ignoreGesture(this.input)),setTimeout((()=>this.updateMirror()),0),this.options.actions&&(this.actionbar=this._register(new o.E(this.element)),this.actionbar.push(this.options.actions,{icon:!0,label:!1})),this.applyStyles()}onBlur(){this._hideMessage(),this.options.showPlaceholderOnFocus&&this.input.setAttribute("placeholder","")}onFocus(){this._showMessage(),this.options.showPlaceholderOnFocus&&this.input.setAttribute("placeholder",this.placeholder||"")}setPlaceHolder(e){this.placeholder=e,this.input.setAttribute("placeholder",e)}setTooltip(e){this.tooltip=e,this.hover?this.hover.update(e):this.hover=this._register((0,c.i)().setupManagedHover((0,l.nZ)("mouse"),this.input,e))}get inputElement(){return this.input}get value(){return this.input.value}set value(e){this.input.value!==e&&(this.input.value=e,this.onValueChange())}get height(){return"number"===typeof this.cachedHeight?this.cachedHeight:s.OK(this.element)}focus(){this.input.focus()}blur(){this.input.blur()}hasFocus(){return s.X7(this.input)}select(e=null){this.input.select(),e&&(this.input.setSelectionRange(e.start,e.end),e.end===this.input.value.length&&(this.input.scrollLeft=this.input.scrollWidth))}isSelectionAtEnd(){return this.input.selectionEnd===this.input.value.length&&this.input.selectionStart===this.input.selectionEnd}getSelection(){const e=this.input.selectionStart;if(null===e)return null;return{start:e,end:this.input.selectionEnd??e}}enable(){this.input.removeAttribute("disabled")}disable(){this.blur(),this.input.disabled=!0,this._hideMessage()}set paddingRight(e){this.input.style.width=`calc(100% - ${e}px)`,this.mirror&&(this.mirror.style.paddingRight=e+"px")}updateScrollDimensions(){if("number"!==typeof this.cachedContentHeight||"number"!==typeof this.cachedHeight||!this.scrollableElement)return;const e=this.cachedContentHeight,t=this.cachedHeight,i=this.input.scrollTop;this.scrollableElement.setScrollDimensions({scrollHeight:e,height:t}),this.scrollableElement.setScrollPosition({scrollTop:i})}showMessage(e,t){if("open"===this.state&&(0,m.aI)(this.message,e))return;this.message=e,this.element.classList.remove("idle"),this.element.classList.remove("info"),this.element.classList.remove("warning"),this.element.classList.remove("error"),this.element.classList.add(this.classForType(e.type));const i=this.stylesForType(this.message.type);this.element.style.border=`1px solid ${s.gI(i.border,"transparent")}`,this.message.content&&(this.hasFocus()||t)&&this._showMessage()}hideMessage(){this.message=null,this.element.classList.remove("info"),this.element.classList.remove("warning"),this.element.classList.remove("error"),this.element.classList.add("idle"),this._hideMessage(),this.applyStyles()}validate(){let e=null;return this.validation&&(e=this.validation(this.value),e?(this.inputElement.setAttribute("aria-invalid","true"),this.showMessage(e)):this.inputElement.hasAttribute("aria-invalid")&&(this.inputElement.removeAttribute("aria-invalid"),this.hideMessage())),e?.type}stylesForType(e){const t=this.options.inputBoxStyles;switch(e){case 1:return{border:t.inputValidationInfoBorder,background:t.inputValidationInfoBackground,foreground:t.inputValidationInfoForeground};case 2:return{border:t.inputValidationWarningBorder,background:t.inputValidationWarningBackground,foreground:t.inputValidationWarningForeground};default:return{border:t.inputValidationErrorBorder,background:t.inputValidationErrorBackground,foreground:t.inputValidationErrorForeground}}}classForType(e){switch(e){case 1:return"info";case 2:return"warning";default:return"error"}}_showMessage(){if(!this.contextViewProvider||!this.message)return;let e;const t=()=>e.style.width=s.Tr(this.element)+"px";let i;this.contextViewProvider.showContextView({getAnchor:()=>this.element,anchorAlignment:1,render:i=>{if(!this.message)return null;e=s.BC(i,_(".monaco-inputbox-container")),t();const n={inline:!0,className:"monaco-inputbox-message"},o=this.message.formatContent?(0,r.yk)(this.message.content,n):(0,r.S5)(this.message.content,n);o.classList.add(this.classForType(this.message.type));const a=this.stylesForType(this.message.type);return o.style.backgroundColor=a.background??"",o.style.color=a.foreground??"",o.style.border=a.border?`1px solid ${a.border}`:"",s.BC(e,o),null},onHide:()=>{this.state="closed"},layout:t}),i=3===this.message.type?f.kg("alertErrorMessage","Error: {0}",this.message.content):2===this.message.type?f.kg("alertWarningMessage","Warning: {0}",this.message.content):f.kg("alertInfoMessage","Info: {0}",this.message.content),a.xE(i),this.state="open"}_hideMessage(){this.contextViewProvider&&("open"===this.state&&this.contextViewProvider.hideContextView(),this.state="idle")}onValueChange(){this._onDidChange.fire(this.value),this.validate(),this.updateMirror(),this.input.classList.toggle("empty",!this.value),"open"===this.state&&this.contextViewProvider&&this.contextViewProvider.layout()}updateMirror(){if(!this.mirror)return;const e=this.value,t=10===e.charCodeAt(e.length-1)?" ":"";(e+t).replace(/\u000c/g,"")?this.mirror.textContent=e+t:this.mirror.innerText="\xa0",this.layout()}applyStyles(){const e=this.options.inputBoxStyles,t=e.inputBackground??"",i=e.inputForeground??"",n=e.inputBorder??"";this.element.style.backgroundColor=t,this.element.style.color=i,this.input.style.backgroundColor="inherit",this.input.style.color=i,this.element.style.border=`1px solid ${s.gI(n,"transparent")}`}layout(){if(!this.mirror)return;const e=this.cachedContentHeight;this.cachedContentHeight=s.OK(this.mirror),e!==this.cachedContentHeight&&(this.cachedHeight=Math.min(this.cachedContentHeight,this.maxHeight),this.input.style.height=this.cachedHeight+"px",this._onDidHeightChange.fire(this.cachedContentHeight))}insertAtCursor(e){const t=this.inputElement,i=t.selectionStart,s=t.selectionEnd,n=t.value;null!==i&&null!==s&&(this.value=n.substr(0,i)+e+n.substr(s),t.setSelectionRange(i+1,i+1),this.layout())}dispose(){this._hideMessage(),this.message=null,this.actionbar?.dispose(),super.dispose()}}class E extends C{constructor(e,t,i){const n=f.kg({key:"history.inputbox.hint.suffix.noparens",comment:['Text is the suffix of an input field placeholder coming after the action the input field performs, this will be used when the input field ends in a closing parenthesis ")", for example "Filter (e.g. text, !exclude)". The character inserted into the final string is \u21c5 to represent the up and down arrow keys.']}," or {0} for history","\u21c5"),r=f.kg({key:"history.inputbox.hint.suffix.inparens",comment:['Text is the suffix of an input field placeholder coming after the action the input field performs, this will be used when the input field does NOT end in a closing parenthesis (eg. "Find"). The character inserted into the final string is \u21c5 to represent the up and down arrow keys.']}," ({0} for history)","\u21c5");super(e,t,i),this._onDidFocus=this._register(new u.vl),this.onDidFocus=this._onDidFocus.event,this._onDidBlur=this._register(new u.vl),this.onDidBlur=this._onDidBlur.event,this.history=new p(i.history,100);const o=()=>{if(i.showHistoryHint&&i.showHistoryHint()&&!this.placeholder.endsWith(n)&&!this.placeholder.endsWith(r)&&this.history.getHistory().length){const e=this.placeholder.endsWith(")")?n:r,t=this.placeholder+e;i.showPlaceholderOnFocus&&!s.X7(this.input)?this.placeholder=t:this.setPlaceHolder(t)}};this.observer=new MutationObserver(((e,t)=>{e.forEach((e=>{e.target.textContent||o()}))})),this.observer.observe(this.input,{attributeFilter:["class"]}),this.onfocus(this.input,(()=>o())),this.onblur(this.input,(()=>{const e=e=>{if(this.placeholder.endsWith(e)){const t=this.placeholder.slice(0,this.placeholder.length-e.length);return i.showPlaceholderOnFocus?this.placeholder=t:this.setPlaceHolder(t),!0}return!1};e(r)||e(n)}))}dispose(){super.dispose(),this.observer&&(this.observer.disconnect(),this.observer=void 0)}addToHistory(e){this.value&&(e||this.value!==this.getCurrentValue())&&this.history.add(this.value)}isAtLastInHistory(){return this.history.isLast()}isNowhereInHistory(){return this.history.isNowhere()}showNextValue(){this.history.has(this.value)||this.addToHistory();let e=this.getNextValue();e&&(e=e===this.value?this.getNextValue():e),this.value=e??"",a.h5(this.value?this.value:f.kg("clearedInput","Cleared Input"))}showPreviousValue(){this.history.has(this.value)||this.addToHistory();let e=this.getPreviousValue();e&&(e=e===this.value?this.getPreviousValue():e),e&&(this.value=e,a.h5(this.value))}setPlaceHolder(e){super.setPlaceHolder(e),this.setTooltip(e)}onBlur(){super.onBlur(),this._onDidBlur.fire()}onFocus(){super.onFocus(),this._onDidFocus.fire()}getCurrentValue(){let e=this.history.current();return e||(e=this.history.last(),this.history.next()),e}getPreviousValue(){return this.history.previous()||this.history.first()}getNextValue(){return this.history.next()}}},92080:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"mdx",extensions:[".mdx"],aliases:["MDX","mdx"],loader:()=>i.e(26214).then(i.bind(i,26214))})},92159:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8.53 11.78a.75.75 0 0 1-1.06 0l-2.5-2.5a.75.75 0 0 1 1.06-1.06l1.22 1.22V1.75a.75.75 0 0 1 1.5 0v7.69l1.22-1.22a.75.75 0 1 1 1.06 1.06zM1.75 13.5a.75.75 0 0 0 0 1.5h12.5a.75.75 0 0 0 0-1.5z",clipRule:"evenodd"}))},92368:(e,t,i)=>{"use strict";i.d(t,{$y:()=>p,AV:()=>E,Am:()=>d,D1:()=>v,EK:()=>w,MZ:()=>S,Mu:()=>y,Nu:()=>f,O8:()=>R,Vs:()=>b,pN:()=>m,pY:()=>u,rX:()=>g,uN:()=>_});var s=i(46041),n=i(18447),r=i(5662),o=i(31308),a=i(4983),c=i(83069),l=i(36677),h=i(50973);function d(e,t,i,s){if(0===e.length)return t;if(0===t.length)return e;const n=[];let r=0,o=0;for(;rh?(n.push(c),o++):(n.push(s(a,c)),r++,o++)}for(;r`Apply decorations from ${t.debugName}`},(e=>{const i=t.read(e);s.set(i)}))),i.add({dispose:()=>{s.clear()}}),i}function g(e,t){return e.appendChild(t),(0,r.s)((()=>{t.remove()}))}function p(e,t){return e.prepend(t),(0,r.s)((()=>{t.remove()}))}class m extends r.jG{get width(){return this._width}get height(){return this._height}get automaticLayout(){return this._automaticLayout}constructor(e,t){super(),this._automaticLayout=!1,this.elementSizeObserver=this._register(new a.u(e,t)),this._width=(0,o.FY)(this,this.elementSizeObserver.getWidth()),this._height=(0,o.FY)(this,this.elementSizeObserver.getHeight()),this._register(this.elementSizeObserver.onDidChange((e=>(0,o.Rn)((e=>{this._width.set(this.elementSizeObserver.getWidth(),e),this._height.set(this.elementSizeObserver.getHeight(),e)})))))}observe(e){this.elementSizeObserver.observe(e)}setAutomaticLayout(e){this._automaticLayout=e,e?this.elementSizeObserver.startObserving():this.elementSizeObserver.stopObserving()}}function f(e,t,i){let s=t.get(),n=s,r=s;const a=(0,o.FY)("animatedValue",s);let c=-1;let l;function h(){const t=Date.now()-c;var i,o,d,u;r=Math.floor((o=n,d=s-n,(i=t)===(u=300)?o+d:d*(1-Math.pow(2,-10*i/u))+o)),t<300?l=e.requestAnimationFrame(h):r=s,a.set(r,void 0)}return i.add((0,o.Y)({createEmptyChangeSummary:()=>({animate:!1}),handleChange:(e,i)=>(e.didChange(t)&&(i.animate=i.animate||e.change),!0)},((i,o)=>{void 0!==l&&(e.cancelAnimationFrame(l),l=void 0),n=r,s=t.read(i),c=Date.now()-(o.animate?0:300),h()}))),a}class _ extends r.jG{constructor(e,t,i){super(),this._register(new C(e,i)),this._register(E(i,{height:t.actualHeight,top:t.actualTop}))}}class v{get afterLineNumber(){return this._afterLineNumber.get()}constructor(e,t){this._afterLineNumber=e,this.heightInPx=t,this.domNode=document.createElement("div"),this._actualTop=(0,o.FY)(this,void 0),this._actualHeight=(0,o.FY)(this,void 0),this.actualTop=this._actualTop,this.actualHeight=this._actualHeight,this.showInHiddenAreas=!0,this.onChange=this._afterLineNumber,this.onDomNodeTop=e=>{this._actualTop.set(e,void 0)},this.onComputedHeight=e=>{this._actualHeight.set(e,void 0)}}}class C{static{this._counter=0}constructor(e,t){this._editor=e,this._domElement=t,this._overlayWidgetId="managedOverlayWidget-"+C._counter++,this._overlayWidget={getId:()=>this._overlayWidgetId,getDomNode:()=>this._domElement,getPosition:()=>null},this._editor.addOverlayWidget(this._overlayWidget)}dispose(){this._editor.removeOverlayWidget(this._overlayWidget)}}function E(e,t){return(0,o.fm)((i=>{for(let[s,n]of Object.entries(t))n&&"object"===typeof n&&"read"in n&&(n=n.read(i)),"number"===typeof n&&(n=`${n}px`),s=s.replace(/[A-Z]/g,(e=>"-"+e.toLowerCase())),e.style[s]=n}))}function b(e,t,i,s){const n=new r.Cm,a=[];return n.add((0,o.yC)(((n,r)=>{const c=t.read(n),l=new Map,h=new Map;i&&i(!0),e.changeViewZones((e=>{for(const t of a)e.removeZone(t),s?.delete(t);a.length=0;for(const t of c){const i=e.addZone(t);t.setZoneId&&t.setZoneId(i),a.push(i),s?.add(i),l.set(t,i)}})),i&&i(!1),r.add((0,o.Y)({createEmptyChangeSummary:()=>({zoneIds:[]}),handleChange(e,t){const i=h.get(e.changedObservable);return void 0!==i&&t.zoneIds.push(i),!0}},((t,s)=>{for(const e of c)e.onChange&&(h.set(e.onChange,l.get(e)),e.onChange.read(t));i&&i(!0),e.changeViewZones((e=>{for(const t of s.zoneIds)e.layoutZone(t)})),i&&i(!1)})))}))),n.add({dispose(){i&&i(!0),e.changeViewZones((e=>{for(const t of a)e.removeZone(t)})),s?.clear(),i&&i(!1)}}),n}class S extends n.Qi{dispose(){super.dispose(!0)}}function y(e,t){const i=(0,s.Uk)(t,(t=>t.original.startLineNumber<=e.lineNumber));if(!i)return l.Q.fromPositions(e);if(i.original.endLineNumberExclusive<=e.lineNumber){const t=e.lineNumber-i.original.endLineNumberExclusive+i.modified.endLineNumberExclusive;return l.Q.fromPositions(new c.y(t,e.column))}if(!i.innerChanges)return l.Q.fromPositions(new c.y(i.modified.startLineNumber,1));const n=(0,s.Uk)(i.innerChanges,(t=>t.originalRange.getStartPosition().isBeforeOrEqual(e)));if(!n){const t=e.lineNumber-i.original.startLineNumber+i.modified.startLineNumber;return l.Q.fromPositions(new c.y(t,e.column))}if(n.originalRange.containsPosition(e))return n.modifiedRange;{const t=(r=n.originalRange.getEndPosition(),o=e,r.lineNumber===o.lineNumber?new h.W(0,o.column-r.column):new h.W(o.lineNumber-r.lineNumber,o.column-1));return l.Q.fromPositions(t.addToPosition(n.modifiedRange.getEndPosition()))}var r,o}function w(e,t){let i;return e.filter((e=>{const s=t(e,i);return i=e,s}))}class R{static create(e,t=void 0){return new L(e,e,t)}static createWithDisposable(e,t,i=void 0){const s=new r.Cm;return s.add(t),s.add(e),new L(e,s,i)}}class L extends R{constructor(e,t,i){super(),this.object=e,this._disposable=t,this._debugOwner=i,this._refCount=1,this._isDisposed=!1,this._owners=[],i&&this._addOwner(i)}_addOwner(e){e&&this._owners.push(e)}createNewRef(e){return this._refCount++,e&&this._addOwner(e),new T(this,e)}dispose(){this._isDisposed||(this._isDisposed=!0,this._decreaseRefCount(this._debugOwner))}_decreaseRefCount(e){if(this._refCount--,0===this._refCount&&this._disposable.dispose(),e){const t=this._owners.indexOf(e);-1!==t&&this._owners.splice(t,1)}}}class T extends R{constructor(e,t){super(),this._base=e,this._debugOwner=t,this._isDisposed=!1}get object(){return this._base.object}createNewRef(e){return this._base.createNewRef(e)}dispose(){this._isDisposed||(this._isDisposed=!0,this._base._decreaseRefCount(this._debugOwner))}}},92403:(e,t,i)=>{"use strict";i.d(t,{B:()=>u,m:()=>C});var s=i(8597),n=i(56245),r=i(25154),o=i(90766),a=i(58694),c=i(41234),l=i(5662),h=i(98067),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};var u;!function(e){e.North="north",e.South="south",e.East="east",e.West="west"}(u||(u={}));const g=new c.vl;const p=new c.vl;class m{constructor(e){this.el=e,this.disposables=new l.Cm}get onPointerMove(){return this.disposables.add(new n.f((0,s.zk)(this.el),"mousemove")).event}get onPointerUp(){return this.disposables.add(new n.f((0,s.zk)(this.el),"mouseup")).event}dispose(){this.disposables.dispose()}}d([a.B],m.prototype,"onPointerMove",null),d([a.B],m.prototype,"onPointerUp",null);class f{get onPointerMove(){return this.disposables.add(new n.f(this.el,r.B.Change)).event}get onPointerUp(){return this.disposables.add(new n.f(this.el,r.B.End)).event}constructor(e){this.el=e,this.disposables=new l.Cm}dispose(){this.disposables.dispose()}}d([a.B],f.prototype,"onPointerMove",null),d([a.B],f.prototype,"onPointerUp",null);class _{get onPointerMove(){return this.factory.onPointerMove}get onPointerUp(){return this.factory.onPointerUp}constructor(e){this.factory=e}dispose(){}}d([a.B],_.prototype,"onPointerMove",null),d([a.B],_.prototype,"onPointerUp",null);const v="pointer-events-disabled";class C extends l.jG{get state(){return this._state}get orthogonalStartSash(){return this._orthogonalStartSash}get orthogonalEndSash(){return this._orthogonalEndSash}set state(e){this._state!==e&&(this.el.classList.toggle("disabled",0===e),this.el.classList.toggle("minimum",1===e),this.el.classList.toggle("maximum",2===e),this._state=e,this.onDidEnablementChange.fire(e))}set orthogonalStartSash(e){if(this._orthogonalStartSash!==e){if(this.orthogonalStartDragHandleDisposables.clear(),this.orthogonalStartSashDisposables.clear(),e){const t=t=>{this.orthogonalStartDragHandleDisposables.clear(),0!==t&&(this._orthogonalStartDragHandle=(0,s.BC)(this.el,(0,s.$)(".orthogonal-drag-handle.start")),this.orthogonalStartDragHandleDisposables.add((0,l.s)((()=>this._orthogonalStartDragHandle.remove()))),this.orthogonalStartDragHandleDisposables.add(new n.f(this._orthogonalStartDragHandle,"mouseenter")).event((()=>C.onMouseEnter(e)),void 0,this.orthogonalStartDragHandleDisposables),this.orthogonalStartDragHandleDisposables.add(new n.f(this._orthogonalStartDragHandle,"mouseleave")).event((()=>C.onMouseLeave(e)),void 0,this.orthogonalStartDragHandleDisposables))};this.orthogonalStartSashDisposables.add(e.onDidEnablementChange.event(t,this)),t(e.state)}this._orthogonalStartSash=e}}set orthogonalEndSash(e){if(this._orthogonalEndSash!==e){if(this.orthogonalEndDragHandleDisposables.clear(),this.orthogonalEndSashDisposables.clear(),e){const t=t=>{this.orthogonalEndDragHandleDisposables.clear(),0!==t&&(this._orthogonalEndDragHandle=(0,s.BC)(this.el,(0,s.$)(".orthogonal-drag-handle.end")),this.orthogonalEndDragHandleDisposables.add((0,l.s)((()=>this._orthogonalEndDragHandle.remove()))),this.orthogonalEndDragHandleDisposables.add(new n.f(this._orthogonalEndDragHandle,"mouseenter")).event((()=>C.onMouseEnter(e)),void 0,this.orthogonalEndDragHandleDisposables),this.orthogonalEndDragHandleDisposables.add(new n.f(this._orthogonalEndDragHandle,"mouseleave")).event((()=>C.onMouseLeave(e)),void 0,this.orthogonalEndDragHandleDisposables))};this.orthogonalEndSashDisposables.add(e.onDidEnablementChange.event(t,this)),t(e.state)}this._orthogonalEndSash=e}}constructor(e,t,i){super(),this.hoverDelay=300,this.hoverDelayer=this._register(new o.ve(this.hoverDelay)),this._state=3,this.onDidEnablementChange=this._register(new c.vl),this._onDidStart=this._register(new c.vl),this._onDidChange=this._register(new c.vl),this._onDidReset=this._register(new c.vl),this._onDidEnd=this._register(new c.vl),this.orthogonalStartSashDisposables=this._register(new l.Cm),this.orthogonalStartDragHandleDisposables=this._register(new l.Cm),this.orthogonalEndSashDisposables=this._register(new l.Cm),this.orthogonalEndDragHandleDisposables=this._register(new l.Cm),this.onDidStart=this._onDidStart.event,this.onDidChange=this._onDidChange.event,this.onDidReset=this._onDidReset.event,this.onDidEnd=this._onDidEnd.event,this.linkedSash=void 0,this.el=(0,s.BC)(e,(0,s.$)(".monaco-sash")),i.orthogonalEdge&&this.el.classList.add(`orthogonal-edge-${i.orthogonalEdge}`),h.zx&&this.el.classList.add("mac");const a=this._register(new n.f(this.el,"mousedown")).event;this._register(a((t=>this.onPointerStart(t,new m(e))),this));const d=this._register(new n.f(this.el,"dblclick")).event;this._register(d(this.onPointerDoublePress,this));const u=this._register(new n.f(this.el,"mouseenter")).event;this._register(u((()=>C.onMouseEnter(this))));const _=this._register(new n.f(this.el,"mouseleave")).event;this._register(_((()=>C.onMouseLeave(this)))),this._register(r.q.addTarget(this.el));const v=this._register(new n.f(this.el,r.B.Start)).event;this._register(v((e=>this.onPointerStart(e,new f(this.el))),this));const E=this._register(new n.f(this.el,r.B.Tap)).event;let b;this._register(E((e=>{if(b)return clearTimeout(b),b=void 0,void this.onPointerDoublePress(e);clearTimeout(b),b=setTimeout((()=>b=void 0),250)}),this)),"number"===typeof i.size?(this.size=i.size,0===i.orientation?this.el.style.width=`${this.size}px`:this.el.style.height=`${this.size}px`):(this.size=4,this._register(g.event((e=>{this.size=e,this.layout()})))),this._register(p.event((e=>this.hoverDelay=e))),this.layoutProvider=t,this.orthogonalStartSash=i.orthogonalStartSash,this.orthogonalEndSash=i.orthogonalEndSash,this.orientation=i.orientation||0,1===this.orientation?(this.el.classList.add("horizontal"),this.el.classList.remove("vertical")):(this.el.classList.remove("horizontal"),this.el.classList.add("vertical")),this.el.classList.toggle("debug",false),this.layout()}onPointerStart(e,t){s.fs.stop(e);let i=!1;if(!e.__orthogonalSashEvent){const s=this.getOrthogonalSash(e);s&&(i=!0,e.__orthogonalSashEvent=!0,s.onPointerStart(e,new _(t)))}if(this.linkedSash&&!e.__linkedSashEvent&&(e.__linkedSashEvent=!0,this.linkedSash.onPointerStart(e,new _(t))),!this.state)return;const n=this.el.ownerDocument.getElementsByTagName("iframe");for(const s of n)s.classList.add(v);const r=e.pageX,o=e.pageY,a=e.altKey,c={startX:r,currentX:r,startY:o,currentY:o,altKey:a};this.el.classList.add("active"),this._onDidStart.fire(c);const d=(0,s.li)(this.el),u=()=>{let e="";e=i?"all-scroll":1===this.orientation?1===this.state?"s-resize":2===this.state?"n-resize":h.zx?"row-resize":"ns-resize":1===this.state?"e-resize":2===this.state?"w-resize":h.zx?"col-resize":"ew-resize",d.textContent=`* { cursor: ${e} !important; }`},g=new l.Cm;u(),i||this.onDidEnablementChange.event(u,null,g);t.onPointerMove((e=>{s.fs.stop(e,!1);const t={startX:r,currentX:e.pageX,startY:o,currentY:e.pageY,altKey:a};this._onDidChange.fire(t)}),null,g),t.onPointerUp((e=>{s.fs.stop(e,!1),d.remove(),this.el.classList.remove("active"),this._onDidEnd.fire(),g.dispose();for(const t of n)t.classList.remove(v)}),null,g),g.add(t)}onPointerDoublePress(e){const t=this.getOrthogonalSash(e);t&&t._onDidReset.fire(),this.linkedSash&&this.linkedSash._onDidReset.fire(),this._onDidReset.fire()}static onMouseEnter(e,t=!1){e.el.classList.contains("active")?(e.hoverDelayer.cancel(),e.el.classList.add("hover")):e.hoverDelayer.trigger((()=>e.el.classList.add("hover")),e.hoverDelay).then(void 0,(()=>{})),!t&&e.linkedSash&&C.onMouseEnter(e.linkedSash,!0)}static onMouseLeave(e,t=!1){e.hoverDelayer.cancel(),e.el.classList.remove("hover"),!t&&e.linkedSash&&C.onMouseLeave(e.linkedSash,!0)}clearSashHoverState(){C.onMouseLeave(this)}layout(){if(0===this.orientation){const e=this.layoutProvider;this.el.style.left=e.getVerticalSashLeft(this)-this.size/2+"px",e.getVerticalSashTop&&(this.el.style.top=e.getVerticalSashTop(this)+"px"),e.getVerticalSashHeight&&(this.el.style.height=e.getVerticalSashHeight(this)+"px")}else{const e=this.layoutProvider;this.el.style.top=e.getHorizontalSashTop(this)-this.size/2+"px",e.getHorizontalSashLeft&&(this.el.style.left=e.getHorizontalSashLeft(this)+"px"),e.getHorizontalSashWidth&&(this.el.style.width=e.getHorizontalSashWidth(this)+"px")}}getOrthogonalSash(e){const t=e.initialTarget??e.target;if(t&&(0,s.sb)(t))return t.classList.contains("orthogonal-drag-handle")?t.classList.contains("start")?this.orthogonalStartSash:this.orthogonalEndSash:void 0}dispose(){super.dispose(),this.el.remove()}}},92473:(e,t,i)=>{"use strict";i.d(t,{Gb:()=>m,Ax:()=>p,rk:()=>S});var s=i(60413),n=i(55275),r=i(98067),o=i(80624);class a{static _createRange(){return this._handyReadyRange||(this._handyReadyRange=document.createRange()),this._handyReadyRange}static _detachRange(e,t){e.selectNodeContents(t)}static _readClientRects(e,t,i,s,n){const r=this._createRange();try{return r.setStart(e,t),r.setEnd(i,s),r.getClientRects()}catch(o){return null}finally{this._detachRange(r,n)}}static _mergeAdjacentRanges(e){if(1===e.length)return e;e.sort(o.IO.compare);const t=[];let i=0,s=e[0];for(let n=1,r=e.length;n=r.left?s.width=Math.max(s.width,r.left+r.width-s.left):(t[i++]=s,s=r)}return t[i++]=s,t}static _createHorizontalRangesFromClientRects(e,t,i){if(!e||0===e.length)return null;const s=[];for(let n=0,r=e.length;no)return null;if((t=Math.min(o,Math.max(0,t)))===(s=Math.min(o,Math.max(0,s)))&&i===n&&0===i&&!e.children[t].firstChild){const i=e.children[t].getClientRects();return r.markDidDomLayout(),this._createHorizontalRangesFromClientRects(i,r.clientRectDeltaLeft,r.clientRectScale)}t!==s&&s>0&&0===n&&(s--,n=1073741824);let a=e.children[t].firstChild,c=e.children[s].firstChild;if(a&&c||(!a&&0===i&&t>0&&(a=e.children[t-1].firstChild,i=1073741824),!c&&0===n&&s>0&&(c=e.children[s-1].firstChild,n=1073741824)),!a||!c)return null;i=Math.min(a.textContent.length,Math.max(0,i)),n=Math.min(c.textContent.length,Math.max(0,n));const l=this._readClientRects(a,i,c,n,r.endNode);return r.markDidDomLayout(),this._createHorizontalRangesFromClientRects(l,r.clientRectDeltaLeft,r.clientRectScale)}}var c=i(25521),l=i(35600),h=i(86723),d=i(87908);const u=!!r.ib||!(r.j9||s.gm||s.nr);let g=!0;class p{constructor(e,t){this.themeType=t;const i=e.options,s=i.get(50),n=i.get(38);this.renderWhitespace="off"===n?i.get(100):"none",this.renderControlCharacters=i.get(95),this.spaceWidth=s.spaceWidth,this.middotWidth=s.middotWidth,this.wsmiddotWidth=s.wsmiddotWidth,this.useMonospaceOptimizations=s.isMonospace&&!i.get(33),this.canUseHalfwidthRightwardsArrow=s.canUseHalfwidthRightwardsArrow,this.lineHeight=i.get(67),this.stopRenderingLineAfter=i.get(118),this.fontLigatures=i.get(51)}equals(e){return this.themeType===e.themeType&&this.renderWhitespace===e.renderWhitespace&&this.renderControlCharacters===e.renderControlCharacters&&this.spaceWidth===e.spaceWidth&&this.middotWidth===e.middotWidth&&this.wsmiddotWidth===e.wsmiddotWidth&&this.useMonospaceOptimizations===e.useMonospaceOptimizations&&this.canUseHalfwidthRightwardsArrow===e.canUseHalfwidthRightwardsArrow&&this.lineHeight===e.lineHeight&&this.stopRenderingLineAfter===e.stopRenderingLineAfter&&this.fontLigatures===e.fontLigatures}}class m{static{this.CLASS_NAME="view-line"}constructor(e){this._options=e,this._isMaybeInvalid=!0,this._renderedViewLine=null}getDomNode(){return this._renderedViewLine&&this._renderedViewLine.domNode?this._renderedViewLine.domNode.domNode:null}setDomNode(e){if(!this._renderedViewLine)throw new Error("I have no rendered view line to set the dom node to...");this._renderedViewLine.domNode=(0,n.Z)(e)}onContentChanged(){this._isMaybeInvalid=!0}onTokensChanged(){this._isMaybeInvalid=!0}onDecorationsChanged(){this._isMaybeInvalid=!0}onOptionsChanged(e){this._isMaybeInvalid=!0,this._options=e}onSelectionChanged(){return!(!(0,h.Bb)(this._options.themeType)&&"selection"!==this._options.renderWhitespace)&&(this._isMaybeInvalid=!0,!0)}renderLine(e,t,i,s,n){if(!1===this._isMaybeInvalid)return!1;this._isMaybeInvalid=!1;const r=s.getViewLineRenderingData(e),o=this._options,a=c.d.filter(r.inlineDecorations,e,r.minColumn,r.maxColumn);let p=null;if((0,h.Bb)(o.themeType)||"selection"===this._options.renderWhitespace){const t=s.selections;for(const i of t){if(i.endLineNumbere)continue;const t=i.startLineNumber===e?i.startColumn:r.minColumn,s=i.endLineNumber===e?i.endColumn:r.maxColumn;t');const v=(0,l.UW)(_,n);n.appendString("");let E=null;return g&&u&&r.isBasicASCII&&o.useMonospaceOptimizations&&0===v.containsForeignElements&&(E=new f(this._renderedViewLine?this._renderedViewLine.domNode:null,_,v.characterMapping)),E||(E=C(this._renderedViewLine?this._renderedViewLine.domNode:null,_,v.characterMapping,v.containsRTL,v.containsForeignElements)),this._renderedViewLine=E,!0}layoutLine(e,t,i){this._renderedViewLine&&this._renderedViewLine.domNode&&(this._renderedViewLine.domNode.setTop(t),this._renderedViewLine.domNode.setHeight(i))}getWidth(e){return this._renderedViewLine?this._renderedViewLine.getWidth(e):0}getWidthIsFast(){return!this._renderedViewLine||this._renderedViewLine.getWidthIsFast()}needsMonospaceFontCheck(){return!!this._renderedViewLine&&this._renderedViewLine instanceof f}monospaceAssumptionsAreValid(){return this._renderedViewLine&&this._renderedViewLine instanceof f?this._renderedViewLine.monospaceAssumptionsAreValid():g}onMonospaceAssumptionsInvalidated(){this._renderedViewLine&&this._renderedViewLine instanceof f&&(this._renderedViewLine=this._renderedViewLine.toSlowRenderedLine())}getVisibleRangesForRange(e,t,i,s){if(!this._renderedViewLine)return null;t=Math.min(this._renderedViewLine.input.lineContent.length+1,Math.max(1,t)),i=Math.min(this._renderedViewLine.input.lineContent.length+1,Math.max(1,i));const n=this._renderedViewLine.input.stopRenderingLineAfter;if(-1!==n&&t>n+1&&i>n+1)return new o.pj(!0,[new o.IO(this.getWidth(s),0)]);-1!==n&&t>n+1&&(t=n+1),-1!==n&&i>n+1&&(i=n+1);const r=this._renderedViewLine.getVisibleRangesForRange(e,t,i,s);return r&&r.length>0?new o.pj(!1,r):null}getColumnOfNodeOffset(e,t){return this._renderedViewLine?this._renderedViewLine.getColumnOfNodeOffset(e,t):1}}class f{constructor(e,t,i){this._cachedWidth=-1,this.domNode=e,this.input=t;const s=Math.floor(t.lineContent.length/300);if(s>0){this._keyColumnPixelOffsetCache=new Float32Array(s);for(let e=0;e=2&&(console.warn("monospace assumptions have been violated, therefore disabling monospace optimizations!"),g=!1)}return g}toSlowRenderedLine(){return C(this.domNode,this.input,this._characterMapping,!1,0)}getVisibleRangesForRange(e,t,i,s){const n=this._getColumnPixelOffset(e,t,s),r=this._getColumnPixelOffset(e,i,s);return[new o.IO(n,r-n)]}_getColumnPixelOffset(e,t,i){if(t<=300){const e=this._characterMapping.getHorizontalOffset(t);return this._charWidth*e}const s=Math.floor((t-1)/300)-1,n=300*(s+1)+1;let r=-1;if(this._keyColumnPixelOffsetCache&&(r=this._keyColumnPixelOffsetCache[s],-1===r&&(r=this._actualReadPixelOffset(e,n,i),this._keyColumnPixelOffsetCache[s]=r)),-1===r){const e=this._characterMapping.getHorizontalOffset(t);return this._charWidth*e}const o=this._characterMapping.getHorizontalOffset(n),a=this._characterMapping.getHorizontalOffset(t);return r+this._charWidth*(a-o)}_getReadingTarget(e){return e.domNode.firstChild}_actualReadPixelOffset(e,t,i){if(!this.domNode)return-1;const s=this._characterMapping.getDomPosition(t),n=a.readHorizontalRanges(this._getReadingTarget(this.domNode),s.partIndex,s.charIndex,s.partIndex,s.charIndex,i);return n&&0!==n.length?n[0].left:-1}getColumnOfNodeOffset(e,t){return S(this._characterMapping,e,t)}}class _{constructor(e,t,i,s,n){if(this.domNode=e,this.input=t,this._characterMapping=i,this._isWhitespaceOnly=/^\s*$/.test(t.lineContent),this._containsForeignElements=n,this._cachedWidth=-1,this._pixelOffsetCache=null,!s||0===this._characterMapping.length){this._pixelOffsetCache=new Float32Array(Math.max(2,this._characterMapping.length+1));for(let e=0,t=this._characterMapping.length;e<=t;e++)this._pixelOffsetCache[e]=-1}}_getReadingTarget(e){return e.domNode.firstChild}getWidth(e){return this.domNode?(-1===this._cachedWidth&&(this._cachedWidth=this._getReadingTarget(this.domNode).offsetWidth,e?.markDidDomLayout()),this._cachedWidth):0}getWidthIsFast(){return-1!==this._cachedWidth}getVisibleRangesForRange(e,t,i,s){if(!this.domNode)return null;if(null!==this._pixelOffsetCache){const n=this._readPixelOffset(this.domNode,e,t,s);if(-1===n)return null;const r=this._readPixelOffset(this.domNode,e,i,s);return-1===r?null:[new o.IO(n,r-n)]}return this._readVisibleRangesForRange(this.domNode,e,t,i,s)}_readVisibleRangesForRange(e,t,i,s,n){if(i===s){const s=this._readPixelOffset(e,t,i,n);return-1===s?null:[new o.IO(s,0)]}return this._readRawVisibleRangesForRange(e,i,s,n)}_readPixelOffset(e,t,i,s){if(0===this._characterMapping.length){if(0===this._containsForeignElements)return 0;if(2===this._containsForeignElements)return 0;if(1===this._containsForeignElements)return this.getWidth(s);const t=this._getReadingTarget(e);return t.firstChild?(s.markDidDomLayout(),t.firstChild.offsetWidth):0}if(null!==this._pixelOffsetCache){const n=this._pixelOffsetCache[i];if(-1!==n)return n;const r=this._actualReadPixelOffset(e,t,i,s);return this._pixelOffsetCache[i]=r,r}return this._actualReadPixelOffset(e,t,i,s)}_actualReadPixelOffset(e,t,i,s){if(0===this._characterMapping.length){const t=a.readHorizontalRanges(this._getReadingTarget(e),0,0,0,0,s);return t&&0!==t.length?t[0].left:-1}if(i===this._characterMapping.length&&this._isWhitespaceOnly&&0===this._containsForeignElements)return this.getWidth(s);const n=this._characterMapping.getDomPosition(i),r=a.readHorizontalRanges(this._getReadingTarget(e),n.partIndex,n.charIndex,n.partIndex,n.charIndex,s);if(!r||0===r.length)return-1;const o=r[0].left;if(this.input.isBasicASCII){const e=this._characterMapping.getHorizontalOffset(i),t=Math.round(this.input.spaceWidth*e);if(Math.abs(t-o)<=1)return t}return o}_readRawVisibleRangesForRange(e,t,i,s){if(1===t&&i===this._characterMapping.length)return[new o.IO(0,this.getWidth(s))];const n=this._characterMapping.getDomPosition(t),r=this._characterMapping.getDomPosition(i);return a.readHorizontalRanges(this._getReadingTarget(e),n.partIndex,n.charIndex,r.partIndex,r.charIndex,s)}getColumnOfNodeOffset(e,t){return S(this._characterMapping,e,t)}}class v extends _{_readVisibleRangesForRange(e,t,i,s,n){const r=super._readVisibleRangesForRange(e,t,i,s,n);if(!r||0===r.length||i===s||1===i&&s===this._characterMapping.length)return r;if(!this.input.containsRTL){const i=this._readPixelOffset(e,t,s,n);if(-1!==i){const e=r[r.length-1];e.left{"use strict";i.d(t,{AL:()=>d,Vs:()=>h,x9:()=>u,xD:()=>c,yP:()=>l});var s=i(25890),n=i(91508),r=i(83069),o=i(36677),a=i(75295);class c{constructor(e,t){this.lineNumber=e,this.parts=t}equals(e){return this.lineNumber===e.lineNumber&&this.parts.length===e.parts.length&&this.parts.every(((t,i)=>t.equals(e.parts[i])))}renderForScreenReader(e){if(0===this.parts.length)return"";const t=this.parts[this.parts.length-1],i=e.substr(0,t.column-1);return new a.mF([...this.parts.map((e=>new a.WR(o.Q.fromPositions(new r.y(1,e.column)),e.lines.join("\n"))))]).applyToString(i).substring(this.parts[0].column-1)}isEmpty(){return this.parts.every((e=>0===e.lines.length))}get lineCount(){return 1+this.parts.reduce(((e,t)=>e+t.lines.length-1),0)}}class l{constructor(e,t,i){this.column=e,this.text=t,this.preview=i,this.lines=(0,n.uz)(this.text)}equals(e){return this.column===e.column&&this.lines.length===e.lines.length&&this.lines.every(((t,i)=>t===e.lines[i]))}}class h{constructor(e,t,i,s=0){this.lineNumber=e,this.columnRange=t,this.text=i,this.additionalReservedLineCount=s,this.parts=[new l(this.columnRange.endColumnExclusive,this.text,!1)],this.newLines=(0,n.uz)(this.text)}renderForScreenReader(e){return this.newLines.join("\n")}get lineCount(){return this.newLines.length}isEmpty(){return this.parts.every((e=>0===e.lines.length))}equals(e){return this.lineNumber===e.lineNumber&&this.columnRange.equals(e.columnRange)&&this.newLines.length===e.newLines.length&&this.newLines.every(((t,i)=>t===e.newLines[i]))&&this.additionalReservedLineCount===e.additionalReservedLineCount}}function d(e,t){return(0,s.aI)(e,t,u)}function u(e,t){return e===t||!(!e||!t)&&((e instanceof c&&t instanceof c||e instanceof h&&t instanceof h)&&e.equals(t))}},92719:(e,t,i)=>{"use strict";var s;i.d(t,{Q:()=>s}),function(e){function t(e,t){if(e.start>=t.end||t.start>=e.end)return{start:0,end:0};const i=Math.max(e.start,t.start),s=Math.min(e.end,t.end);return s-i<=0?{start:0,end:0}:{start:i,end:s}}function i(e){return e.end-e.start<=0}e.intersect=t,e.isEmpty=i,e.intersects=function(e,s){return!i(t(e,s))},e.relativeComplement=function(e,t){const s=[],n={start:e.start,end:Math.min(t.start,e.end)},r={start:Math.max(t.end,e.start),end:e.end};return i(n)||s.push(n),i(r)||s.push(r),s}}(s||(s={}))},92727:(e,t,i)=>{"use strict";i.d(t,{EN:()=>s.editor,eo:()=>s.languages,vl:()=>s.Emitter});var s=i(80781)},92778:(e,t,i)=>{e.exports=function(e){const t=i(94297),s=i(34420);return function(i,n,r){n=Object.assign({},n,{format:t.JSON,showDecoded:!1,compact:!1,escapeWhitespace:!0});let o=i.$value;try{o=JSON.parse(i.$value)}catch(a){console.error("Invalid JSON string",i.$value)}return e(s(o,n),n,r)}}},92896:(e,t,i)=>{"use strict";i.d(t,{GP:()=>c,LM:()=>o,Uv:()=>g,kI:()=>h,nt:()=>a,or:()=>d,qL:()=>l,vo:()=>u});var s=i(25890),n=i(91508),r=i(36677);class o{constructor(e,t,i,s){this._viewportBrand=void 0,this.top=0|e,this.left=0|t,this.width=0|i,this.height=0|s}}class a{constructor(e,t){this.tabSize=e,this.data=t}}class c{constructor(e,t,i,s,n,r,o){this._viewLineDataBrand=void 0,this.content=e,this.continuesWithWrappedLine=t,this.minColumn=i,this.maxColumn=s,this.startVisibleColumn=n,this.tokens=r,this.inlineDecorations=o}}class l{constructor(e,t,i,s,n,r,o,a,c,h){this.minColumn=e,this.maxColumn=t,this.content=i,this.continuesWithWrappedLine=s,this.isBasicASCII=l.isBasicASCII(i,r),this.containsRTL=l.containsRTL(i,this.isBasicASCII,n),this.tokens=o,this.inlineDecorations=a,this.tabSize=c,this.startVisibleColumn=h}static isBasicASCII(e,t){return!t||n.aC(e)}static containsRTL(e,t,i){return!(t||!i)&&n.E_(e)}}class h{constructor(e,t,i){this.range=e,this.inlineClassName=t,this.type=i}}class d{constructor(e,t,i,s){this.startOffset=e,this.endOffset=t,this.inlineClassName=i,this.inlineClassNameAffectsLetterSpacing=s}toInlineDecoration(e){return new h(new r.Q(e,this.startOffset+1,e,this.endOffset+1),this.inlineClassName,this.inlineClassNameAffectsLetterSpacing?3:0)}}class u{constructor(e,t){this._viewModelDecorationBrand=void 0,this.range=e,this.options=t}}class g{constructor(e,t,i){this.color=e,this.zIndex=t,this.data=i}static compareByRenderingProps(e,t){return e.zIndex===t.zIndex?e.colort.color?1:0:e.zIndex-t.zIndex}static equals(e,t){return e.color===t.color&&e.zIndex===t.zIndex&&s.aI(e.data,t.data)}static equalsArr(e,t){return s.aI(e,t,g.equals)}}},93090:(e,t,i)=>{"use strict";i.d(t,{hb:()=>K,B8:()=>ee,MH:()=>j,_C:()=>E,W0:()=>D,Bm:()=>F,B6:()=>A,b$:()=>O,bm:()=>I,mh:()=>z,tX:()=>V,Es:()=>P,xu:()=>M,bG:()=>Y});var s=i(8597),n=i(56245),r=i(72962),o=i(25154),a=i(11007);class c{constructor(e){this.spliceables=e}splice(e,t,i){this.spliceables.forEach((s=>s.splice(e,t,i)))}}var l=i(25890),h=i(90766),d=i(47661),u=i(58694),g=i(41234),p=i(26690),m=i(5662),f=i(1592),_=i(98067),v=i(631);i(48215);class C extends Error{constructor(e,t){super(`ListError [${e}] ${t}`)}}var E,b,S=i(66700),y=i(47358),w=i(31308),R=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};class L{constructor(e){this.trait=e,this.renderedElements=[]}get templateId(){return`template:${this.trait.name}`}renderTemplate(e){return e}renderElement(e,t,i){const s=this.renderedElements.findIndex((e=>e.templateData===i));if(s>=0){const e=this.renderedElements[s];this.trait.unrender(i),e.index=t}else{const e={index:t,templateData:i};this.renderedElements.push(e)}this.trait.renderIndex(t,i)}splice(e,t,i){const s=[];for(const n of this.renderedElements)n.index=e+t&&s.push({index:n.index+i-t,templateData:n.templateData});this.renderedElements=s}renderIndexes(e){for(const{index:t,templateData:i}of this.renderedElements)e.indexOf(t)>-1&&this.trait.renderIndex(t,i)}disposeTemplate(e){const t=this.renderedElements.findIndex((t=>t.templateData===e));t<0||this.renderedElements.splice(t,1)}}class T{get name(){return this._trait}get renderer(){return new L(this)}constructor(e){this._trait=e,this.indexes=[],this.sortedIndexes=[],this._onChange=new g.vl,this.onChange=this._onChange.event}splice(e,t,i){const s=i.length-t,n=e+t,r=[];let o=0;for(;o=n;)r.push(this.sortedIndexes[o++]+s);this.renderer.splice(e,t,i.length),this._set(r,r)}renderIndex(e,t){t.classList.toggle(this._trait,this.contains(e))}unrender(e){e.classList.remove(this._trait)}set(e,t){return this._set(e,[...e].sort(Q),t)}_set(e,t,i){const s=this.indexes,n=this.sortedIndexes;this.indexes=e,this.sortedIndexes=t;const r=$(n,e);return this.renderer.renderIndexes(r),this._onChange.fire({indexes:e,browserEvent:i}),s}get(){return this.indexes}contains(e){return(0,l.El)(this.sortedIndexes,e,Q)>=0}dispose(){(0,m.AS)(this._onChange)}}R([u.B],T.prototype,"renderer",null);class x extends T{constructor(e){super("selected"),this.setAriaSelected=e}renderIndex(e,t){super.renderIndex(e,t),this.setAriaSelected&&(this.contains(e)?t.setAttribute("aria-selected","true"):t.setAttribute("aria-selected","false"))}}class k{constructor(e,t,i){this.trait=e,this.view=t,this.identityProvider=i}splice(e,t,i){if(!this.identityProvider)return this.trait.splice(e,t,new Array(i.length).fill(!1));const s=this.trait.get().map((e=>this.identityProvider.getId(this.view.element(e)).toString()));if(0===s.length)return this.trait.splice(e,t,new Array(i.length).fill(!1));const n=new Set(s),r=i.map((e=>n.has(this.identityProvider.getId(e).toString())));this.trait.splice(e,t,r)}}function A(e){return"INPUT"===e.tagName||"TEXTAREA"===e.tagName}function N(e,t){return!!e.classList.contains(t)||!e.classList.contains("monaco-list")&&(!!e.parentElement&&N(e.parentElement,t))}function I(e){return N(e,"monaco-editor")}function O(e){return N(e,"monaco-custom-toggle")}function D(e){return N(e,"action-item")}function M(e){return N(e,"monaco-tree-sticky-row")}function P(e){return e.classList.contains("monaco-tree-sticky-container")}function F(e){return!!("A"===e.tagName&&e.classList.contains("monaco-button")||"DIV"===e.tagName&&e.classList.contains("monaco-button-dropdown"))||!e.classList.contains("monaco-list")&&(!!e.parentElement&&F(e.parentElement))}class U{get onKeyDown(){return g.Jh.chain(this.disposables.add(new n.f(this.view.domNode,"keydown")).event,(e=>e.filter((e=>!A(e.target))).map((e=>new r.Z(e)))))}constructor(e,t,i){this.list=e,this.view=t,this.disposables=new m.Cm,this.multipleSelectionDisposables=new m.Cm,this.multipleSelectionSupport=i.multipleSelectionSupport,this.disposables.add(this.onKeyDown((e=>{switch(e.keyCode){case 3:return this.onEnter(e);case 16:return this.onUpArrow(e);case 18:return this.onDownArrow(e);case 11:return this.onPageUpArrow(e);case 12:return this.onPageDownArrow(e);case 9:return this.onEscape(e);case 31:this.multipleSelectionSupport&&(_.zx?e.metaKey:e.ctrlKey)&&this.onCtrlA(e)}})))}updateOptions(e){void 0!==e.multipleSelectionSupport&&(this.multipleSelectionSupport=e.multipleSelectionSupport)}onEnter(e){e.preventDefault(),e.stopPropagation(),this.list.setSelection(this.list.getFocus(),e.browserEvent)}onUpArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusPrevious(1,!1,e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onDownArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusNext(1,!1,e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onPageUpArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusPreviousPage(e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onPageDownArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusNextPage(e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onCtrlA(e){e.preventDefault(),e.stopPropagation(),this.list.setSelection((0,l.y1)(this.list.length),e.browserEvent),this.list.setAnchor(void 0),this.view.domNode.focus()}onEscape(e){this.list.getSelection().length&&(e.preventDefault(),e.stopPropagation(),this.list.setSelection([],e.browserEvent),this.list.setAnchor(void 0),this.view.domNode.focus())}dispose(){this.disposables.dispose(),this.multipleSelectionDisposables.dispose()}}R([u.B],U.prototype,"onKeyDown",null),function(e){e[e.Automatic=0]="Automatic",e[e.Trigger=1]="Trigger"}(E||(E={})),function(e){e[e.Idle=0]="Idle",e[e.Typing=1]="Typing"}(b||(b={}));const H=new class{mightProducePrintableCharacter(e){return!(e.ctrlKey||e.metaKey||e.altKey)&&(e.keyCode>=31&&e.keyCode<=56||e.keyCode>=21&&e.keyCode<=30||e.keyCode>=98&&e.keyCode<=107||e.keyCode>=85&&e.keyCode<=95)}};class B{constructor(e,t,i,s,n){this.list=e,this.view=t,this.keyboardNavigationLabelProvider=i,this.keyboardNavigationEventFilter=s,this.delegate=n,this.enabled=!1,this.state=b.Idle,this.mode=E.Automatic,this.triggered=!1,this.previouslyFocused=-1,this.enabledDisposables=new m.Cm,this.disposables=new m.Cm,this.updateOptions(e.options)}updateOptions(e){e.typeNavigationEnabled??1?this.enable():this.disable(),this.mode=e.typeNavigationMode??E.Automatic}enable(){if(this.enabled)return;let e=!1;const t=g.Jh.chain(this.enabledDisposables.add(new n.f(this.view.domNode,"keydown")).event,(t=>t.filter((e=>!A(e.target))).filter((()=>this.mode===E.Automatic||this.triggered)).map((e=>new r.Z(e))).filter((t=>e||this.keyboardNavigationEventFilter(t))).filter((e=>this.delegate.mightProducePrintableCharacter(e))).forEach((e=>s.fs.stop(e,!0))).map((e=>e.browserEvent.key)))),i=g.Jh.debounce(t,(()=>null),800,void 0,void 0,void 0,this.enabledDisposables);g.Jh.reduce(g.Jh.any(t,i),((e,t)=>null===t?null:(e||"")+t),void 0,this.enabledDisposables)(this.onInput,this,this.enabledDisposables),i(this.onClear,this,this.enabledDisposables),t((()=>e=!0),void 0,this.enabledDisposables),i((()=>e=!1),void 0,this.enabledDisposables),this.enabled=!0,this.triggered=!1}disable(){this.enabled&&(this.enabledDisposables.clear(),this.enabled=!1,this.triggered=!1)}onClear(){const e=this.list.getFocus();if(e.length>0&&e[0]===this.previouslyFocused){const t=this.list.options.accessibilityProvider?.getAriaLabel(this.list.element(e[0]));"string"===typeof t?(0,a.xE)(t):t&&(0,a.xE)(t.get())}this.previouslyFocused=-1}onInput(e){if(!e)return this.state=b.Idle,void(this.triggered=!1);const t=this.list.getFocus(),i=t.length>0?t[0]:0,s=this.state===b.Idle?1:0;this.state=b.Typing;for(let n=0;n1&&1===s.length)return this.previouslyFocused=i,this.list.setFocus([t]),void this.list.reveal(t)}}}else if("undefined"===typeof o||(0,p.WP)(e,o))return this.previouslyFocused=i,this.list.setFocus([t]),void this.list.reveal(t)}}dispose(){this.disable(),this.enabledDisposables.dispose(),this.disposables.dispose()}}class W{constructor(e,t){this.list=e,this.view=t,this.disposables=new m.Cm;const i=g.Jh.chain(this.disposables.add(new n.f(t.domNode,"keydown")).event,(e=>e.filter((e=>!A(e.target))).map((e=>new r.Z(e)))));g.Jh.chain(i,(e=>e.filter((e=>2===e.keyCode&&!e.ctrlKey&&!e.metaKey&&!e.shiftKey&&!e.altKey))))(this.onTab,this,this.disposables)}onTab(e){if(e.target!==this.view.domNode)return;const t=this.list.getFocus();if(0===t.length)return;const i=this.view.domElement(t[0]);if(!i)return;const n=i.querySelector("[tabIndex]");if(!n||!(0,s.sb)(n)||-1===n.tabIndex)return;const r=(0,s.zk)(n).getComputedStyle(n);"hidden"!==r.visibility&&"none"!==r.display&&(e.preventDefault(),e.stopPropagation(),n.focus())}dispose(){this.disposables.dispose()}}function V(e){return _.zx?e.browserEvent.metaKey:e.browserEvent.ctrlKey}function z(e){return e.browserEvent.shiftKey}const G={isSelectionSingleChangeEvent:V,isSelectionRangeChangeEvent:z};class j{constructor(e){this.list=e,this.disposables=new m.Cm,this._onPointer=new g.vl,this.onPointer=this._onPointer.event,!1!==e.options.multipleSelectionSupport&&(this.multipleSelectionController=this.list.options.multipleSelectionController||G),this.mouseSupport="undefined"===typeof e.options.mouseSupport||!!e.options.mouseSupport,this.mouseSupport&&(e.onMouseDown(this.onMouseDown,this,this.disposables),e.onContextMenu(this.onContextMenu,this,this.disposables),e.onMouseDblClick(this.onDoubleClick,this,this.disposables),e.onTouchStart(this.onMouseDown,this,this.disposables),this.disposables.add(o.q.addTarget(e.getHTMLElement()))),g.Jh.any(e.onMouseClick,e.onMouseMiddleClick,e.onTap)(this.onViewPointer,this,this.disposables)}updateOptions(e){void 0!==e.multipleSelectionSupport&&(this.multipleSelectionController=void 0,e.multipleSelectionSupport&&(this.multipleSelectionController=this.list.options.multipleSelectionController||G))}isSelectionSingleChangeEvent(e){return!!this.multipleSelectionController&&this.multipleSelectionController.isSelectionSingleChangeEvent(e)}isSelectionRangeChangeEvent(e){return!!this.multipleSelectionController&&this.multipleSelectionController.isSelectionRangeChangeEvent(e)}isSelectionChangeEvent(e){return this.isSelectionSingleChangeEvent(e)||this.isSelectionRangeChangeEvent(e)}onMouseDown(e){I(e.browserEvent.target)||(0,s.bq)()!==e.browserEvent.target&&this.list.domFocus()}onContextMenu(e){if(A(e.browserEvent.target)||I(e.browserEvent.target))return;const t="undefined"===typeof e.index?[]:[e.index];this.list.setFocus(t,e.browserEvent)}onViewPointer(e){if(!this.mouseSupport)return;if(A(e.browserEvent.target)||I(e.browserEvent.target))return;if(e.browserEvent.isHandledByList)return;e.browserEvent.isHandledByList=!0;const t=e.index;return"undefined"===typeof t?(this.list.setFocus([],e.browserEvent),this.list.setSelection([],e.browserEvent),void this.list.setAnchor(void 0)):this.isSelectionChangeEvent(e)?this.changeSelection(e):(this.list.setFocus([t],e.browserEvent),this.list.setAnchor(t),i=e.browserEvent,(0,s.Er)(i)&&2===i.button||this.list.setSelection([t],e.browserEvent),void this._onPointer.fire(e));var i}onDoubleClick(e){if(A(e.browserEvent.target)||I(e.browserEvent.target))return;if(this.isSelectionChangeEvent(e))return;if(e.browserEvent.isHandledByList)return;e.browserEvent.isHandledByList=!0;const t=this.list.getFocus();this.list.setSelection(t,e.browserEvent)}changeSelection(e){const t=e.index;let i=this.list.getAnchor();if(this.isSelectionRangeChangeEvent(e)){if("undefined"===typeof i){i=this.list.getFocus()[0]??t,this.list.setAnchor(i)}const s=Math.min(i,t),n=Math.max(i,t),r=(0,l.y1)(s,n+1),o=this.list.getSelection(),a=function(e,t){const i=e.indexOf(t);if(-1===i)return[];const s=[];let n=i-1;for(;n>=0&&e[n]===t-(i-n);)s.push(e[n--]);s.reverse(),n=i;for(;n=e.length)i.push(t[n++]);else if(n>=t.length)i.push(e[s++]);else{if(e[s]===t[n]){s++,n++;continue}e[s]e!==t));this.list.setFocus([t]),this.list.setAnchor(t),i.length===s.length?this.list.setSelection([...s,t],e.browserEvent):this.list.setSelection(s,e.browserEvent)}}dispose(){this.disposables.dispose()}}class K{constructor(e,t){this.styleElement=e,this.selectorSuffix=t}style(e){const t=this.selectorSuffix&&`.${this.selectorSuffix}`,i=[];e.listBackground&&i.push(`.monaco-list${t} .monaco-list-rows { background: ${e.listBackground}; }`),e.listFocusBackground&&(i.push(`.monaco-list${t}:focus .monaco-list-row.focused { background-color: ${e.listFocusBackground}; }`),i.push(`.monaco-list${t}:focus .monaco-list-row.focused:hover { background-color: ${e.listFocusBackground}; }`)),e.listFocusForeground&&i.push(`.monaco-list${t}:focus .monaco-list-row.focused { color: ${e.listFocusForeground}; }`),e.listActiveSelectionBackground&&(i.push(`.monaco-list${t}:focus .monaco-list-row.selected { background-color: ${e.listActiveSelectionBackground}; }`),i.push(`.monaco-list${t}:focus .monaco-list-row.selected:hover { background-color: ${e.listActiveSelectionBackground}; }`)),e.listActiveSelectionForeground&&i.push(`.monaco-list${t}:focus .monaco-list-row.selected { color: ${e.listActiveSelectionForeground}; }`),e.listActiveSelectionIconForeground&&i.push(`.monaco-list${t}:focus .monaco-list-row.selected .codicon { color: ${e.listActiveSelectionIconForeground}; }`),e.listFocusAndSelectionBackground&&i.push(`\n\t\t\t\t.monaco-drag-image,\n\t\t\t\t.monaco-list${t}:focus .monaco-list-row.selected.focused { background-color: ${e.listFocusAndSelectionBackground}; }\n\t\t\t`),e.listFocusAndSelectionForeground&&i.push(`\n\t\t\t\t.monaco-drag-image,\n\t\t\t\t.monaco-list${t}:focus .monaco-list-row.selected.focused { color: ${e.listFocusAndSelectionForeground}; }\n\t\t\t`),e.listInactiveFocusForeground&&(i.push(`.monaco-list${t} .monaco-list-row.focused { color: ${e.listInactiveFocusForeground}; }`),i.push(`.monaco-list${t} .monaco-list-row.focused:hover { color: ${e.listInactiveFocusForeground}; }`)),e.listInactiveSelectionIconForeground&&i.push(`.monaco-list${t} .monaco-list-row.focused .codicon { color: ${e.listInactiveSelectionIconForeground}; }`),e.listInactiveFocusBackground&&(i.push(`.monaco-list${t} .monaco-list-row.focused { background-color: ${e.listInactiveFocusBackground}; }`),i.push(`.monaco-list${t} .monaco-list-row.focused:hover { background-color: ${e.listInactiveFocusBackground}; }`)),e.listInactiveSelectionBackground&&(i.push(`.monaco-list${t} .monaco-list-row.selected { background-color: ${e.listInactiveSelectionBackground}; }`),i.push(`.monaco-list${t} .monaco-list-row.selected:hover { background-color: ${e.listInactiveSelectionBackground}; }`)),e.listInactiveSelectionForeground&&i.push(`.monaco-list${t} .monaco-list-row.selected { color: ${e.listInactiveSelectionForeground}; }`),e.listHoverBackground&&i.push(`.monaco-list${t}:not(.drop-target):not(.dragging) .monaco-list-row:hover:not(.selected):not(.focused) { background-color: ${e.listHoverBackground}; }`),e.listHoverForeground&&i.push(`.monaco-list${t}:not(.drop-target):not(.dragging) .monaco-list-row:hover:not(.selected):not(.focused) { color: ${e.listHoverForeground}; }`);const n=(0,s.gI)(e.listFocusAndSelectionOutline,(0,s.gI)(e.listSelectionOutline,e.listFocusOutline??""));n&&i.push(`.monaco-list${t}:focus .monaco-list-row.focused.selected { outline: 1px solid ${n}; outline-offset: -1px;}`),e.listFocusOutline&&i.push(`\n\t\t\t\t.monaco-drag-image,\n\t\t\t\t.monaco-list${t}:focus .monaco-list-row.focused { outline: 1px solid ${e.listFocusOutline}; outline-offset: -1px; }\n\t\t\t\t.monaco-workbench.context-menu-visible .monaco-list${t}.last-focused .monaco-list-row.focused { outline: 1px solid ${e.listFocusOutline}; outline-offset: -1px; }\n\t\t\t`);const r=(0,s.gI)(e.listSelectionOutline,e.listInactiveFocusOutline??"");r&&i.push(`.monaco-list${t} .monaco-list-row.focused.selected { outline: 1px dotted ${r}; outline-offset: -1px; }`),e.listSelectionOutline&&i.push(`.monaco-list${t} .monaco-list-row.selected { outline: 1px dotted ${e.listSelectionOutline}; outline-offset: -1px; }`),e.listInactiveFocusOutline&&i.push(`.monaco-list${t} .monaco-list-row.focused { outline: 1px dotted ${e.listInactiveFocusOutline}; outline-offset: -1px; }`),e.listHoverOutline&&i.push(`.monaco-list${t} .monaco-list-row:hover { outline: 1px dashed ${e.listHoverOutline}; outline-offset: -1px; }`),e.listDropOverBackground&&i.push(`\n\t\t\t\t.monaco-list${t}.drop-target,\n\t\t\t\t.monaco-list${t} .monaco-list-rows.drop-target,\n\t\t\t\t.monaco-list${t} .monaco-list-row.drop-target { background-color: ${e.listDropOverBackground} !important; color: inherit !important; }\n\t\t\t`),e.listDropBetweenBackground&&(i.push(`\n\t\t\t.monaco-list${t} .monaco-list-rows.drop-target-before .monaco-list-row:first-child::before,\n\t\t\t.monaco-list${t} .monaco-list-row.drop-target-before::before {\n\t\t\t\tcontent: ""; position: absolute; top: 0px; left: 0px; width: 100%; height: 1px;\n\t\t\t\tbackground-color: ${e.listDropBetweenBackground};\n\t\t\t}`),i.push(`\n\t\t\t.monaco-list${t} .monaco-list-rows.drop-target-after .monaco-list-row:last-child::after,\n\t\t\t.monaco-list${t} .monaco-list-row.drop-target-after::after {\n\t\t\t\tcontent: ""; position: absolute; bottom: 0px; left: 0px; width: 100%; height: 1px;\n\t\t\t\tbackground-color: ${e.listDropBetweenBackground};\n\t\t\t}`)),e.tableColumnsBorder&&i.push(`\n\t\t\t\t.monaco-table > .monaco-split-view2,\n\t\t\t\t.monaco-table > .monaco-split-view2 .monaco-sash.vertical::before,\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table:hover > .monaco-split-view2,\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table:hover > .monaco-split-view2 .monaco-sash.vertical::before {\n\t\t\t\t\tborder-color: ${e.tableColumnsBorder};\n\t\t\t\t}\n\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table > .monaco-split-view2,\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table > .monaco-split-view2 .monaco-sash.vertical::before {\n\t\t\t\t\tborder-color: transparent;\n\t\t\t\t}\n\t\t\t`),e.tableOddRowsBackgroundColor&&i.push(`\n\t\t\t\t.monaco-table .monaco-list-row[data-parity=odd]:not(.focused):not(.selected):not(:hover) .monaco-table-tr,\n\t\t\t\t.monaco-table .monaco-list:not(:focus) .monaco-list-row[data-parity=odd].focused:not(.selected):not(:hover) .monaco-table-tr,\n\t\t\t\t.monaco-table .monaco-list:not(.focused) .monaco-list-row[data-parity=odd].focused:not(.selected):not(:hover) .monaco-table-tr {\n\t\t\t\t\tbackground-color: ${e.tableOddRowsBackgroundColor};\n\t\t\t\t}\n\t\t\t`),this.styleElement.textContent=i.join("\n")}}const Y={listFocusBackground:"#7FB0D0",listActiveSelectionBackground:"#0E639C",listActiveSelectionForeground:"#FFFFFF",listActiveSelectionIconForeground:"#FFFFFF",listFocusAndSelectionOutline:"#90C2F9",listFocusAndSelectionBackground:"#094771",listFocusAndSelectionForeground:"#FFFFFF",listInactiveSelectionBackground:"#3F3F46",listInactiveSelectionIconForeground:"#FFFFFF",listHoverBackground:"#2A2D2E",listDropOverBackground:"#383B3D",listDropBetweenBackground:"#EEEEEE",treeIndentGuidesStroke:"#a9a9a9",treeInactiveIndentGuidesStroke:d.Q1.fromHex("#a9a9a9").transparent(.4).toString(),tableColumnsBorder:d.Q1.fromHex("#cccccc").transparent(.2).toString(),tableOddRowsBackgroundColor:d.Q1.fromHex("#cccccc").transparent(.04).toString(),listBackground:void 0,listFocusForeground:void 0,listInactiveSelectionForeground:void 0,listInactiveFocusForeground:void 0,listInactiveFocusBackground:void 0,listHoverForeground:void 0,listFocusOutline:void 0,listInactiveFocusOutline:void 0,listSelectionOutline:void 0,listHoverOutline:void 0,treeStickyScrollBackground:void 0,treeStickyScrollBorder:void 0,treeStickyScrollShadow:void 0},q={keyboardSupport:!0,mouseSupport:!0,multipleSelectionSupport:!0,dnd:{getDragURI:()=>null,onDragStart(){},onDragOver:()=>!1,drop(){},dispose(){}}};function $(e,t){const i=[];let s=0,n=0;for(;s=e.length)i.push(t[n++]);else if(n>=t.length)i.push(e[s++]);else{if(e[s]===t[n]){i.push(e[s]),s++,n++;continue}e[s]e-t;class X{constructor(e,t){this._templateId=e,this.renderers=t}get templateId(){return this._templateId}renderTemplate(e){return this.renderers.map((t=>t.renderTemplate(e)))}renderElement(e,t,i,s){let n=0;for(const r of this.renderers)r.renderElement(e,t,i[n++],s)}disposeElement(e,t,i,s){let n=0;for(const r of this.renderers)r.disposeElement?.(e,t,i[n],s),n+=1}disposeTemplate(e){let t=0;for(const i of this.renderers)i.disposeTemplate(e[t++])}}class Z{constructor(e){this.accessibilityProvider=e,this.templateId="a18n"}renderTemplate(e){return{container:e,disposables:new m.Cm}}renderElement(e,t,i){const s=this.accessibilityProvider.getAriaLabel(e),n=s&&"string"!==typeof s?s:(0,w.lk)(s);i.disposables.add((0,w.fm)((e=>{this.setAriaLabel(e.readObservable(n),i.container)})));const r=this.accessibilityProvider.getAriaLevel&&this.accessibilityProvider.getAriaLevel(e);"number"===typeof r?i.container.setAttribute("aria-level",`${r}`):i.container.removeAttribute("aria-level")}setAriaLabel(e,t){e?t.setAttribute("aria-label",e):t.removeAttribute("aria-label")}disposeElement(e,t,i,s){i.disposables.clear()}disposeTemplate(e){e.disposables.dispose()}}class J{constructor(e,t){this.list=e,this.dnd=t}getDragElements(e){const t=this.list.getSelectedElements();return t.indexOf(e)>-1?t:[e]}getDragURI(e){return this.dnd.getDragURI(e)}getDragLabel(e,t){if(this.dnd.getDragLabel)return this.dnd.getDragLabel(e,t)}onDragStart(e,t){this.dnd.onDragStart?.(e,t)}onDragOver(e,t,i,s,n){return this.dnd.onDragOver(e,t,i,s,n)}onDragLeave(e,t,i,s){this.dnd.onDragLeave?.(e,t,i,s)}onDragEnd(e){this.dnd.onDragEnd?.(e)}drop(e,t,i,s,n){this.dnd.drop(e,t,i,s,n)}dispose(){this.dnd.dispose()}}class ee{get onDidChangeFocus(){return g.Jh.map(this.eventBufferer.wrapEvent(this.focus.onChange),(e=>this.toListEvent(e)),this.disposables)}get onDidChangeSelection(){return g.Jh.map(this.eventBufferer.wrapEvent(this.selection.onChange),(e=>this.toListEvent(e)),this.disposables)}get domId(){return this.view.domId}get onDidScroll(){return this.view.onDidScroll}get onMouseClick(){return this.view.onMouseClick}get onMouseDblClick(){return this.view.onMouseDblClick}get onMouseMiddleClick(){return this.view.onMouseMiddleClick}get onPointer(){return this.mouseController.onPointer}get onMouseDown(){return this.view.onMouseDown}get onMouseOver(){return this.view.onMouseOver}get onMouseOut(){return this.view.onMouseOut}get onTouchStart(){return this.view.onTouchStart}get onTap(){return this.view.onTap}get onContextMenu(){let e=!1;const t=g.Jh.chain(this.disposables.add(new n.f(this.view.domNode,"keydown")).event,(t=>t.map((e=>new r.Z(e))).filter((t=>e=58===t.keyCode||t.shiftKey&&68===t.keyCode)).map((e=>s.fs.stop(e,!0))).filter((()=>!1)))),i=g.Jh.chain(this.disposables.add(new n.f(this.view.domNode,"keyup")).event,(t=>t.forEach((()=>e=!1)).map((e=>new r.Z(e))).filter((e=>58===e.keyCode||e.shiftKey&&68===e.keyCode)).map((e=>s.fs.stop(e,!0))).map((({browserEvent:e})=>{const t=this.getFocus(),i=t.length?t[0]:void 0;return{index:i,element:"undefined"!==typeof i?this.view.element(i):void 0,anchor:"undefined"!==typeof i?this.view.domElement(i):this.view.domNode,browserEvent:e}})))),o=g.Jh.chain(this.view.onContextMenu,(t=>t.filter((t=>!e)).map((({element:e,index:t,browserEvent:i})=>({element:e,index:t,anchor:new y.P((0,s.zk)(this.view.domNode),i),browserEvent:i})))));return g.Jh.any(t,i,o)}get onKeyDown(){return this.disposables.add(new n.f(this.view.domNode,"keydown")).event}get onDidFocus(){return g.Jh.signal(this.disposables.add(new n.f(this.view.domNode,"focus",!0)).event)}get onDidBlur(){return g.Jh.signal(this.disposables.add(new n.f(this.view.domNode,"blur",!0)).event)}constructor(e,t,i,n,r=q){this.user=e,this._options=r,this.focus=new T("focused"),this.anchor=new T("anchor"),this.eventBufferer=new g.at,this._ariaLabel="",this.disposables=new m.Cm,this._onDidDispose=new g.vl,this.onDidDispose=this._onDidDispose.event;const o=this._options.accessibilityProvider&&this._options.accessibilityProvider.getWidgetRole?this._options.accessibilityProvider?.getWidgetRole():"list";this.selection=new x("listbox"!==o);const a=[this.focus.renderer,this.selection.renderer];this.accessibilityProvider=r.accessibilityProvider,this.accessibilityProvider&&(a.push(new Z(this.accessibilityProvider)),this.accessibilityProvider.onDidChangeActiveDescendant?.(this.onDidChangeActiveDescendant,this,this.disposables)),n=n.map((e=>new X(e.templateId,[...a,e])));const l={...r,dnd:r.dnd&&new J(this,r.dnd)};if(this.view=this.createListView(t,i,n,l),this.view.domNode.setAttribute("role",o),r.styleController)this.styleController=r.styleController(this.view.domId);else{const e=(0,s.li)(this.view.domNode);this.styleController=new K(e,this.view.domId)}if(this.spliceable=new c([new k(this.focus,this.view,r.identityProvider),new k(this.selection,this.view,r.identityProvider),new k(this.anchor,this.view,r.identityProvider),this.view]),this.disposables.add(this.focus),this.disposables.add(this.selection),this.disposables.add(this.anchor),this.disposables.add(this.view),this.disposables.add(this._onDidDispose),this.disposables.add(new W(this,this.view)),("boolean"!==typeof r.keyboardSupport||r.keyboardSupport)&&(this.keyboardController=new U(this,this.view,r),this.disposables.add(this.keyboardController)),r.keyboardNavigationLabelProvider){const e=r.keyboardNavigationDelegate||H;this.typeNavigationController=new B(this,this.view,r.keyboardNavigationLabelProvider,r.keyboardNavigationEventFilter??(()=>!0),e),this.disposables.add(this.typeNavigationController)}this.mouseController=this.createMouseController(r),this.disposables.add(this.mouseController),this.onDidChangeFocus(this._onFocusChange,this,this.disposables),this.onDidChangeSelection(this._onSelectionChange,this,this.disposables),this.accessibilityProvider&&(this.ariaLabel=this.accessibilityProvider.getWidgetAriaLabel()),!1!==this._options.multipleSelectionSupport&&this.view.domNode.setAttribute("aria-multiselectable","true")}createListView(e,t,i,s){return new S.uO(e,t,i,s)}createMouseController(e){return new j(this)}updateOptions(e={}){this._options={...this._options,...e},this.typeNavigationController?.updateOptions(this._options),void 0!==this._options.multipleSelectionController&&(this._options.multipleSelectionSupport?this.view.domNode.setAttribute("aria-multiselectable","true"):this.view.domNode.removeAttribute("aria-multiselectable")),this.mouseController.updateOptions(e),this.keyboardController?.updateOptions(e),this.view.updateOptions(e)}get options(){return this._options}splice(e,t,i=[]){if(e<0||e>this.view.length)throw new C(this.user,`Invalid start index: ${e}`);if(t<0)throw new C(this.user,`Invalid delete count: ${t}`);0===t&&0===i.length||this.eventBufferer.bufferEvents((()=>this.spliceable.splice(e,t,i)))}rerender(){this.view.rerender()}element(e){return this.view.element(e)}indexOf(e){return this.view.indexOf(e)}indexAt(e){return this.view.indexAt(e)}get length(){return this.view.length}get contentHeight(){return this.view.contentHeight}get onDidChangeContentHeight(){return this.view.onDidChangeContentHeight}get scrollTop(){return this.view.getScrollTop()}set scrollTop(e){this.view.setScrollTop(e)}get scrollHeight(){return this.view.scrollHeight}get renderHeight(){return this.view.renderHeight}get firstVisibleIndex(){return this.view.firstVisibleIndex}get ariaLabel(){return this._ariaLabel}set ariaLabel(e){this._ariaLabel=e,this.view.domNode.setAttribute("aria-label",e)}domFocus(){this.view.domNode.focus({preventScroll:!0})}layout(e,t){this.view.layout(e,t)}setSelection(e,t){for(const i of e)if(i<0||i>=this.length)throw new C(this.user,`Invalid index ${i}`);this.selection.set(e,t)}getSelection(){return this.selection.get()}getSelectedElements(){return this.getSelection().map((e=>this.view.element(e)))}setAnchor(e){if("undefined"!==typeof e){if(e<0||e>=this.length)throw new C(this.user,`Invalid index ${e}`);this.anchor.set([e])}else this.anchor.set([])}getAnchor(){return(0,l.Fy)(this.anchor.get(),void 0)}getAnchorElement(){const e=this.getAnchor();return"undefined"===typeof e?void 0:this.element(e)}setFocus(e,t){for(const i of e)if(i<0||i>=this.length)throw new C(this.user,`Invalid index ${i}`);this.focus.set(e,t)}focusNext(e=1,t=!1,i,s){if(0===this.length)return;const n=this.focus.get(),r=this.findNextIndex(n.length>0?n[0]+e:0,t,s);r>-1&&this.setFocus([r],i)}focusPrevious(e=1,t=!1,i,s){if(0===this.length)return;const n=this.focus.get(),r=this.findPreviousIndex(n.length>0?n[0]-e:0,t,s);r>-1&&this.setFocus([r],i)}async focusNextPage(e,t){let i=this.view.indexAt(this.view.getScrollTop()+this.view.renderHeight);i=0===i?0:i-1;const s=this.getFocus()[0];if(s!==i&&(void 0===s||i>s)){const n=this.findPreviousIndex(i,!1,t);n>-1&&s!==n?this.setFocus([n],e):this.setFocus([i],e)}else{const n=this.view.getScrollTop();let r=n+this.view.renderHeight;i>s&&(r-=this.view.elementHeight(i)),this.view.setScrollTop(r),this.view.getScrollTop()!==n&&(this.setFocus([]),await(0,h.wR)(0),await this.focusNextPage(e,t))}}async focusPreviousPage(e,t,i=()=>0){let s;const n=i(),r=this.view.getScrollTop()+n;s=0===r?this.view.indexAt(r):this.view.indexAfter(r-1);const o=this.getFocus()[0];if(o!==s&&(void 0===o||o>=s)){const i=this.findNextIndex(s,!1,t);i>-1&&o!==i?this.setFocus([i],e):this.setFocus([s],e)}else{const s=r;this.view.setScrollTop(r-this.view.renderHeight-n),this.view.getScrollTop()+i()!==s&&(this.setFocus([]),await(0,h.wR)(0),await this.focusPreviousPage(e,t,i))}}focusLast(e,t){if(0===this.length)return;const i=this.findPreviousIndex(this.length-1,!1,t);i>-1&&this.setFocus([i],e)}focusFirst(e,t){this.focusNth(0,e,t)}focusNth(e,t,i){if(0===this.length)return;const s=this.findNextIndex(e,!1,i);s>-1&&this.setFocus([s],t)}findNextIndex(e,t=!1,i){for(let s=0;s=this.length&&!t)return-1;if(e%=this.length,!i||i(this.element(e)))return e;e++}return-1}findPreviousIndex(e,t=!1,i){for(let s=0;sthis.view.element(e)))}reveal(e,t,i=0){if(e<0||e>=this.length)throw new C(this.user,`Invalid index ${e}`);const s=this.view.getScrollTop(),n=this.view.elementTop(e),r=this.view.elementHeight(e);if((0,v.Et)(t)){const e=r-this.view.renderHeight+i;this.view.setScrollTop(e*(0,f.qE)(t,0,1)+n-i)}else{const e=n+r,t=s+this.view.renderHeight;n=t||(n=t&&r>=this.view.renderHeight?this.view.setScrollTop(n-i):e>=t&&this.view.setScrollTop(e-this.view.renderHeight))}}getRelativeTop(e,t=0){if(e<0||e>=this.length)throw new C(this.user,`Invalid index ${e}`);const i=this.view.getScrollTop(),s=this.view.elementTop(e),n=this.view.elementHeight(e);if(si+this.view.renderHeight)return null;const r=n-this.view.renderHeight+t;return Math.abs((i+t-s)/r)}getHTMLElement(){return this.view.domNode}getScrollableElement(){return this.view.scrollableElementDomNode}getElementID(e){return this.view.getElementDomId(e)}getElementTop(e){return this.view.elementTop(e)}style(e){this.styleController.style(e)}toListEvent({indexes:e,browserEvent:t}){return{indexes:e,elements:e.map((e=>this.view.element(e))),browserEvent:t}}_onFocusChange(){const e=this.focus.get();this.view.domNode.classList.toggle("element-focused",e.length>0),this.onDidChangeActiveDescendant()}onDidChangeActiveDescendant(){const e=this.focus.get();if(e.length>0){let t;this.accessibilityProvider?.getActiveDescendantId&&(t=this.accessibilityProvider.getActiveDescendantId(this.view.element(e[0]))),this.view.domNode.setAttribute("aria-activedescendant",t||this.view.getElementDomId(e[0]))}else this.view.domNode.removeAttribute("aria-activedescendant")}_onSelectionChange(){const e=this.selection.get();this.view.domNode.classList.toggle("selection-none",0===e.length),this.view.domNode.classList.toggle("selection-single",1===e.length),this.view.domNode.classList.toggle("selection-multiple",e.length>1)}dispose(){this._onDidDispose.fire(),this.disposables.dispose(),this._onDidDispose.dispose()}}R([u.B],ee.prototype,"onDidChangeFocus",null),R([u.B],ee.prototype,"onDidChangeSelection",null),R([u.B],ee.prototype,"onContextMenu",null),R([u.B],ee.prototype,"onKeyDown",null),R([u.B],ee.prototype,"onDidFocus",null),R([u.B],ee.prototype,"onDidBlur",null)},93409:(e,t,i)=>{"use strict";var s=i(78209),n=i(66261);(0,n.x1A)("symbolIcon.arrayForeground",n.CU6,(0,s.kg)("symbolIcon.arrayForeground","The foreground color for array symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.booleanForeground",n.CU6,(0,s.kg)("symbolIcon.booleanForeground","The foreground color for boolean symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.classForeground",{dark:"#EE9D28",light:"#D67E00",hcDark:"#EE9D28",hcLight:"#D67E00"},(0,s.kg)("symbolIcon.classForeground","The foreground color for class symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.colorForeground",n.CU6,(0,s.kg)("symbolIcon.colorForeground","The foreground color for color symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.constantForeground",n.CU6,(0,s.kg)("symbolIcon.constantForeground","The foreground color for constant symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.constructorForeground",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},(0,s.kg)("symbolIcon.constructorForeground","The foreground color for constructor symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.enumeratorForeground",{dark:"#EE9D28",light:"#D67E00",hcDark:"#EE9D28",hcLight:"#D67E00"},(0,s.kg)("symbolIcon.enumeratorForeground","The foreground color for enumerator symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.enumeratorMemberForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.enumeratorMemberForeground","The foreground color for enumerator member symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.eventForeground",{dark:"#EE9D28",light:"#D67E00",hcDark:"#EE9D28",hcLight:"#D67E00"},(0,s.kg)("symbolIcon.eventForeground","The foreground color for event symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.fieldForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.fieldForeground","The foreground color for field symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.fileForeground",n.CU6,(0,s.kg)("symbolIcon.fileForeground","The foreground color for file symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.folderForeground",n.CU6,(0,s.kg)("symbolIcon.folderForeground","The foreground color for folder symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.functionForeground",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},(0,s.kg)("symbolIcon.functionForeground","The foreground color for function symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.interfaceForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.interfaceForeground","The foreground color for interface symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.keyForeground",n.CU6,(0,s.kg)("symbolIcon.keyForeground","The foreground color for key symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.keywordForeground",n.CU6,(0,s.kg)("symbolIcon.keywordForeground","The foreground color for keyword symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.methodForeground",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},(0,s.kg)("symbolIcon.methodForeground","The foreground color for method symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.moduleForeground",n.CU6,(0,s.kg)("symbolIcon.moduleForeground","The foreground color for module symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.namespaceForeground",n.CU6,(0,s.kg)("symbolIcon.namespaceForeground","The foreground color for namespace symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.nullForeground",n.CU6,(0,s.kg)("symbolIcon.nullForeground","The foreground color for null symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.numberForeground",n.CU6,(0,s.kg)("symbolIcon.numberForeground","The foreground color for number symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.objectForeground",n.CU6,(0,s.kg)("symbolIcon.objectForeground","The foreground color for object symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.operatorForeground",n.CU6,(0,s.kg)("symbolIcon.operatorForeground","The foreground color for operator symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.packageForeground",n.CU6,(0,s.kg)("symbolIcon.packageForeground","The foreground color for package symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.propertyForeground",n.CU6,(0,s.kg)("symbolIcon.propertyForeground","The foreground color for property symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.referenceForeground",n.CU6,(0,s.kg)("symbolIcon.referenceForeground","The foreground color for reference symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.snippetForeground",n.CU6,(0,s.kg)("symbolIcon.snippetForeground","The foreground color for snippet symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.stringForeground",n.CU6,(0,s.kg)("symbolIcon.stringForeground","The foreground color for string symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.structForeground",n.CU6,(0,s.kg)("symbolIcon.structForeground","The foreground color for struct symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.textForeground",n.CU6,(0,s.kg)("symbolIcon.textForeground","The foreground color for text symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.typeParameterForeground",n.CU6,(0,s.kg)("symbolIcon.typeParameterForeground","The foreground color for type parameter symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.unitForeground",n.CU6,(0,s.kg)("symbolIcon.unitForeground","The foreground color for unit symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.variableForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.variableForeground","The foreground color for variable symbols. These symbols appear in the outline, breadcrumb, and suggest widget."))},93599:e=>{e.exports=function(){function e(e){return e.$value}return e.isScalar=!0,e}},93630:(e,t,i)=>{"use strict";i.d(t,{Z:()=>l});var s=i(91508),n=i(40579),r=i(19131),o=i(32956),a=i(51934);class c{static createFromLanguage(e,t){function i(e){return t.getKey(`${e.languageId}:::${e.bracketText}`)}const s=new Map;for(const c of e.bracketsNew.openingBrackets){const e=(0,r.qe)(0,c.bracketText.length),t=i(c),l=o.gV.getEmpty().add(t,o.FD);s.set(c.bracketText,new a.ou(e,1,t,l,n.rh.create(e,c,l)))}for(const c of e.bracketsNew.closingBrackets){const e=(0,r.qe)(0,c.bracketText.length);let t=o.gV.getEmpty();const l=c.getOpeningBrackets();for(const s of l)t=t.add(i(s),o.FD);s.set(c.bracketText,new a.ou(e,2,i(l[0]),t,n.rh.create(e,c,t)))}return new c(s)}constructor(e){this.map=e,this.hasRegExp=!1,this._regExpGlobal=null}getRegExpStr(){if(this.isEmpty)return null;{const e=[...this.map.keys()];return e.sort(),e.reverse(),e.map((e=>function(e){let t=(0,s.bm)(e);/^[\w ]+/.test(e)&&(t=`\\b${t}`);/[\w ]+$/.test(e)&&(t=`${t}\\b`);return t}(e))).join("|")}}get regExpGlobal(){if(!this.hasRegExp){const e=this.getRegExpStr();this._regExpGlobal=e?new RegExp(e,"gi"):null,this.hasRegExp=!0}return this._regExpGlobal}getToken(e){return this.map.get(e.toLowerCase())}findClosingTokenText(e){for(const[t,i]of this.map)if(2===i.kind&&i.bracketIds.intersects(e))return t}get isEmpty(){return 0===this.map.size}}class l{constructor(e,t){this.denseKeyProvider=e,this.getLanguageConfiguration=t,this.languageIdToBracketTokens=new Map}didLanguageChange(e){return this.languageIdToBracketTokens.has(e)}getSingleLanguageBracketTokens(e){let t=this.languageIdToBracketTokens.get(e);return t||(t=c.createFromLanguage(this.getLanguageConfiguration(e),this.denseKeyProvider),this.languageIdToBracketTokens.set(e,t)),t}}},93844:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("g",{clipPath:"url(#a)"},s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M9.235 1a.75.75 0 0 1 .74.56l2.034 7.726 1.09-1.908A.75.75 0 0 1 13.75 7h1.5a.75.75 0 0 1 0 1.5h-1.065l-1.784 3.122a.75.75 0 0 1-1.376-.181l-1.71-6.496-2.083 9.466a.75.75 0 0 1-1.446.07L3.544 7.55l-.65 1.085A.75.75 0 0 1 2.25 9H.75a.75.75 0 1 1 0-1.5h1.075l1.282-2.136a.75.75 0 0 1 1.357.155l1.898 5.868 2.156-9.798A.75.75 0 0 1 9.235 1",clipRule:"evenodd"})),s.createElement("defs",null,s.createElement("clipPath",{id:"a"},s.createElement("path",{fill:"currentColor",d:"M0 0h16v16H0z"}))))},93895:(e,t,i)=>{"use strict";i.d(t,{P:()=>r});var s=i(91508),n=i(1245);function r(e,t,i){let r=s.HG(e);return-1===r&&(r=e.length),function(e,t,i){let s=0;for(let o=0;o{"use strict";i.d(t,{c:()=>c});var s=i(8597),n=i(41234),r=i(5662);class o extends r.jG{constructor(e){super(),this._onDidChange=this._register(new n.vl),this.onDidChange=this._onDidChange.event,this._listener=()=>this._handleChange(e,!0),this._mediaQueryList=null,this._handleChange(e,!1)}_handleChange(e,t){this._mediaQueryList?.removeEventListener("change",this._listener),this._mediaQueryList=e.matchMedia(`(resolution: ${e.devicePixelRatio}dppx)`),this._mediaQueryList.addEventListener("change",this._listener),t&&this._onDidChange.fire()}}class a extends r.jG{get value(){return this._value}constructor(e){super(),this._onDidChange=this._register(new n.vl),this.onDidChange=this._onDidChange.event,this._value=this._getPixelRatio(e);const t=this._register(new o(e));this._register(t.onDidChange((()=>{this._value=this._getPixelRatio(e),this._onDidChange.fire(this._value)})))}_getPixelRatio(e){const t=document.createElement("canvas").getContext("2d");return(e.devicePixelRatio||1)/(t.webkitBackingStorePixelRatio||t.mozBackingStorePixelRatio||t.msBackingStorePixelRatio||t.oBackingStorePixelRatio||t.backingStorePixelRatio||1)}}const c=new class{constructor(){this.mapWindowIdToPixelRatioMonitor=new Map}_getOrCreatePixelRatioMonitor(e){const t=(0,s.Q2)(e);let i=this.mapWindowIdToPixelRatioMonitor.get(t);return i||(i=(0,r.lC)(new a(e)),this.mapWindowIdToPixelRatioMonitor.set(t,i),(0,r.lC)(n.Jh.once(s.Fv)((({vscodeWindowId:e})=>{e===t&&(i?.dispose(),this.mapWindowIdToPixelRatioMonitor.delete(t))})))),i}getInstance(e){return this._getOrCreatePixelRatioMonitor(e)}}},94297:e=>{!function(){"use strict";function t(e,t){let i="";for(let s=0;s="0"&&s<="7"));var s}function r(e,t,i){return!(i="0"&&s<="9"||s>="a"&&s<="f"||s>="A"&&s<="F"));var s}const o="json",a="yson",c=" ",l="\xa0",h=function(e){const t=function(t){return e[t]},i="(?:"+Object.keys(e).join("|")+")",s=RegExp(i),n=RegExp(i,"g");return function(e){return e=null===e?"":String(e),s.test(e)?e.replace(n,t):e}},d=h({"&":"&","<":"<",">":">",'"':""","'":"'","`":"`"}),u=h({"&":"&","<":"<",">":">",""":'"',"'":"'","`":"`"});function g(e,t,i){return 0===i||i===t-1||(" "===e[i-1]||" "===e[i+1])}function p(e,t,i){return t&&(e=d(e),i||(e=''+e)),e}function m(e,t,i){return t&&(e=d(e),i&&(e=""+e)),e}function f(e,t){let i='"';return e&&(i=''+d(i)+"",t&&(i=""+i)),i}function _(e,t){return t.split("").map((function(e){const t=e.charCodeAt(0);if(t>255)throw new Error("unipika: input string is not binary.");return i(t,2)})).join(e.nonBreakingIndent?l:c)}function v(e){return e.format===a?";":","}const C=new Set(["A","B","C","D","E","G","I","N","P","R","S","T","U","V","X","Z"]);e.exports={parseSetting:function(e,t,i){return e&&"undefined"!==typeof e[t]?e[t]:i},repeatChar:t,escapeJSONString:function(e,t){const s=t,n=t.length,r=e.asHTML;let o,a,c,l="",h=!1;l+=f(r,h);for(let u=0;u=0||d>=127&&d<=159?(c="\\u"+i(a,4),e.highlightControlCharacter?(l+=p(c,r,h),h=!0):(l+=m(c,r,h),h=!1)):" "===o&&e.escapeWhitespace&&g(s,n,u)?(c=" ",l+=p(c,r,h),h=!0):(l+=m(o,r,h),h=!1);var d;return l+=f(r,h),l},escapeYSONString:function(e,t){const o=t,a=t.length,c=e.asHTML;let l,h,d,u="",_=!1;u+=f(c,_);for(let f=0;f=32?" "===l&&e.escapeWhitespace&&g(o,a,f)?(d=" ",u+=p(d,c,_),_=!0):(u+=m(l,c,_),_=!1):h<8&&h>=0&&n(o,a,f)?(d="\\"+s(h,1),u+=m(d,c,_),_=!1):r(o,a,f)?(d="\\x"+i(h,2),u+=m(d,c,_),_=!1):(d="\\"+s(h,3),u+=m(d,c,_),_=!1);return u+=f(c,_),u},escapeHTMLString:function(e,t){const i=t,s=t.length,n=e.asHTML;let r,o="";o+=f(n,!1);for(let a=0;a":void 0},getAttributesStart:function(e){return e.format===o?"{":e.format===a?"<":void 0},getKeyValueSeparator:function(e){const t=e.nonBreakingIndent?l:c;return e.format===a?t+"="+t:":"+t},getExpressionTerminator:v,getIndent:function(e,i){const s=e.nonBreakingIndent?l:c;return(e.break?"\n":"")+t(s,e.indent*i)},OBJECT_START:"{",OBJECT_END:"}",ARRAY_START:"[",ARRAY_END:"]",YSON_ATTRIBUTES_START:"<",YSON_ATTRIBUTES_END:">",JSON_EXPRESSION_TERMINATOR:",",JSON_KEY_VALUE_SEPARATOR:": ",EMPTY_STRING:"",WHITESPACE:c,NON_BREAKING_WHITESPACE:l,LINE_FEED:"\n",JSON:o,YSON:a,drawFullView:function(e,t){return e>1||1===e&&!t.compact},drawCompactView:function(e,t){return 1===e&&t.compact},wrapScalar:function(e,t,i){let s=e.$type.replaceAll(".","_"),n="";var r;return(r=e.$category)&&C.has(r.toUpperCase())&&(s+=" pg_category_"+e.$category.toLowerCase()),e.$incomplete&&(s+=" incomplete"),e.$binary&&(s+=" binary"),e.$key&&(s+=" key"),e.$special_key&&(s+=" special-key"),e.$incomplete&&e.$original_value&&(n=e.$original_value),t.asHTML?"'+i+"":i},wrapComplex:function(e,t,i){let s="",n="";return e.$incomplete&&(s+=" incomplete"),e.$incomplete&&e.$original_value&&(n=e.$original_value),"yql.yson"===e.$type&&e.$incomplete?t.asHTML&&s?'':i:t.asHTML&&s?"'+i+"":i},wrapOptional:function(e,t,i){if(e.$optional>0&&null===e.$value){const s=new Array(e.$optional).fill("[").join(""),n=new Array(e.$optional).fill("]").join("");return t.asHTML?''+s+""+i+''+n+"":s+i+n}return i},toPaddedHex:i,toPaddedOctal:s,binaryToHex:_}}()},94318:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"apex",extensions:[".cls"],aliases:["Apex","apex"],mimetypes:["text/x-apex-source","text/x-apex"],loader:()=>i.e(99872).then(i.bind(i,99872))})},94371:(e,t,i)=>{"use strict";i.d(t,{Gn:()=>m,JJ:()=>l,vf:()=>p});var s=i(61059),n=i(87908),r=i(24329),o=i(78209),a=i(1646),c=i(46359);const l=Object.freeze({id:"editor",order:5,type:"object",title:o.kg("editorConfigurationTitle","Editor"),scope:5}),h={...l,properties:{"editor.tabSize":{type:"number",default:r.R.tabSize,minimum:1,markdownDescription:o.kg("tabSize","The number of spaces a tab is equal to. This setting is overridden based on the file contents when {0} is on.","`#editor.detectIndentation#`")},"editor.indentSize":{anyOf:[{type:"string",enum:["tabSize"]},{type:"number",minimum:1}],default:"tabSize",markdownDescription:o.kg("indentSize",'The number of spaces used for indentation or `"tabSize"` to use the value from `#editor.tabSize#`. This setting is overridden based on the file contents when `#editor.detectIndentation#` is on.')},"editor.insertSpaces":{type:"boolean",default:r.R.insertSpaces,markdownDescription:o.kg("insertSpaces","Insert spaces when pressing `Tab`. This setting is overridden based on the file contents when {0} is on.","`#editor.detectIndentation#`")},"editor.detectIndentation":{type:"boolean",default:r.R.detectIndentation,markdownDescription:o.kg("detectIndentation","Controls whether {0} and {1} will be automatically detected when a file is opened based on the file contents.","`#editor.tabSize#`","`#editor.insertSpaces#`")},"editor.trimAutoWhitespace":{type:"boolean",default:r.R.trimAutoWhitespace,description:o.kg("trimAutoWhitespace","Remove trailing auto inserted whitespace.")},"editor.largeFileOptimizations":{type:"boolean",default:r.R.largeFileOptimizations,description:o.kg("largeFileOptimizations","Special handling for large files to disable certain memory intensive features.")},"editor.wordBasedSuggestions":{enum:["off","currentDocument","matchingDocuments","allDocuments"],default:"matchingDocuments",enumDescriptions:[o.kg("wordBasedSuggestions.off","Turn off Word Based Suggestions."),o.kg("wordBasedSuggestions.currentDocument","Only suggest words from the active document."),o.kg("wordBasedSuggestions.matchingDocuments","Suggest words from all open documents of the same language."),o.kg("wordBasedSuggestions.allDocuments","Suggest words from all open documents.")],description:o.kg("wordBasedSuggestions","Controls whether completions should be computed based on words in the document and from which documents they are computed.")},"editor.semanticHighlighting.enabled":{enum:[!0,!1,"configuredByTheme"],enumDescriptions:[o.kg("semanticHighlighting.true","Semantic highlighting enabled for all color themes."),o.kg("semanticHighlighting.false","Semantic highlighting disabled for all color themes."),o.kg("semanticHighlighting.configuredByTheme","Semantic highlighting is configured by the current color theme's `semanticHighlighting` setting.")],default:"configuredByTheme",description:o.kg("semanticHighlighting.enabled","Controls whether the semanticHighlighting is shown for the languages that support it.")},"editor.stablePeek":{type:"boolean",default:!1,markdownDescription:o.kg("stablePeek","Keep peek editors open even when double-clicking their content or when hitting `Escape`.")},"editor.maxTokenizationLineLength":{type:"integer",default:2e4,description:o.kg("maxTokenizationLineLength","Lines above this length will not be tokenized for performance reasons")},"editor.experimental.asyncTokenization":{type:"boolean",default:!0,description:o.kg("editor.experimental.asyncTokenization","Controls whether the tokenization should happen asynchronously on a web worker."),tags:["experimental"]},"editor.experimental.asyncTokenizationLogging":{type:"boolean",default:!1,description:o.kg("editor.experimental.asyncTokenizationLogging","Controls whether async tokenization should be logged. For debugging only.")},"editor.experimental.asyncTokenizationVerification":{type:"boolean",default:!1,description:o.kg("editor.experimental.asyncTokenizationVerification","Controls whether async tokenization should be verified against legacy background tokenization. Might slow down tokenization. For debugging only."),tags:["experimental"]},"editor.experimental.treeSitterTelemetry":{type:"boolean",default:!1,markdownDescription:o.kg("editor.experimental.treeSitterTelemetry","Controls whether tree sitter parsing should be turned on and telemetry collected. Setting `editor.experimental.preferTreeSitter` for specific languages will take precedence."),tags:["experimental"]},"editor.language.brackets":{type:["array","null"],default:null,description:o.kg("schema.brackets","Defines the bracket symbols that increase or decrease the indentation."),items:{type:"array",items:[{type:"string",description:o.kg("schema.openBracket","The opening bracket character or string sequence.")},{type:"string",description:o.kg("schema.closeBracket","The closing bracket character or string sequence.")}]}},"editor.language.colorizedBracketPairs":{type:["array","null"],default:null,description:o.kg("schema.colorizedBracketPairs","Defines the bracket pairs that are colorized by their nesting level if bracket pair colorization is enabled."),items:{type:"array",items:[{type:"string",description:o.kg("schema.openBracket","The opening bracket character or string sequence.")},{type:"string",description:o.kg("schema.closeBracket","The closing bracket character or string sequence.")}]}},"diffEditor.maxComputationTime":{type:"number",default:s.q.maxComputationTime,description:o.kg("maxComputationTime","Timeout in milliseconds after which diff computation is cancelled. Use 0 for no timeout.")},"diffEditor.maxFileSize":{type:"number",default:s.q.maxFileSize,description:o.kg("maxFileSize","Maximum file size in MB for which to compute diffs. Use 0 for no limit.")},"diffEditor.renderSideBySide":{type:"boolean",default:s.q.renderSideBySide,description:o.kg("sideBySide","Controls whether the diff editor shows the diff side by side or inline.")},"diffEditor.renderSideBySideInlineBreakpoint":{type:"number",default:s.q.renderSideBySideInlineBreakpoint,description:o.kg("renderSideBySideInlineBreakpoint","If the diff editor width is smaller than this value, the inline view is used.")},"diffEditor.useInlineViewWhenSpaceIsLimited":{type:"boolean",default:s.q.useInlineViewWhenSpaceIsLimited,description:o.kg("useInlineViewWhenSpaceIsLimited","If enabled and the editor width is too small, the inline view is used.")},"diffEditor.renderMarginRevertIcon":{type:"boolean",default:s.q.renderMarginRevertIcon,description:o.kg("renderMarginRevertIcon","When enabled, the diff editor shows arrows in its glyph margin to revert changes.")},"diffEditor.renderGutterMenu":{type:"boolean",default:s.q.renderGutterMenu,description:o.kg("renderGutterMenu","When enabled, the diff editor shows a special gutter for revert and stage actions.")},"diffEditor.ignoreTrimWhitespace":{type:"boolean",default:s.q.ignoreTrimWhitespace,description:o.kg("ignoreTrimWhitespace","When enabled, the diff editor ignores changes in leading or trailing whitespace.")},"diffEditor.renderIndicators":{type:"boolean",default:s.q.renderIndicators,description:o.kg("renderIndicators","Controls whether the diff editor shows +/- indicators for added/removed changes.")},"diffEditor.codeLens":{type:"boolean",default:s.q.diffCodeLens,description:o.kg("codeLens","Controls whether the editor shows CodeLens.")},"diffEditor.wordWrap":{type:"string",enum:["off","on","inherit"],default:s.q.diffWordWrap,markdownEnumDescriptions:[o.kg("wordWrap.off","Lines will never wrap."),o.kg("wordWrap.on","Lines will wrap at the viewport width."),o.kg("wordWrap.inherit","Lines will wrap according to the {0} setting.","`#editor.wordWrap#`")]},"diffEditor.diffAlgorithm":{type:"string",enum:["legacy","advanced"],default:s.q.diffAlgorithm,markdownEnumDescriptions:[o.kg("diffAlgorithm.legacy","Uses the legacy diffing algorithm."),o.kg("diffAlgorithm.advanced","Uses the advanced diffing algorithm.")],tags:["experimental"]},"diffEditor.hideUnchangedRegions.enabled":{type:"boolean",default:s.q.hideUnchangedRegions.enabled,markdownDescription:o.kg("hideUnchangedRegions.enabled","Controls whether the diff editor shows unchanged regions.")},"diffEditor.hideUnchangedRegions.revealLineCount":{type:"integer",default:s.q.hideUnchangedRegions.revealLineCount,markdownDescription:o.kg("hideUnchangedRegions.revealLineCount","Controls how many lines are used for unchanged regions."),minimum:1},"diffEditor.hideUnchangedRegions.minimumLineCount":{type:"integer",default:s.q.hideUnchangedRegions.minimumLineCount,markdownDescription:o.kg("hideUnchangedRegions.minimumLineCount","Controls how many lines are used as a minimum for unchanged regions."),minimum:1},"diffEditor.hideUnchangedRegions.contextLineCount":{type:"integer",default:s.q.hideUnchangedRegions.contextLineCount,markdownDescription:o.kg("hideUnchangedRegions.contextLineCount","Controls how many lines are used as context when comparing unchanged regions."),minimum:1},"diffEditor.experimental.showMoves":{type:"boolean",default:s.q.experimental.showMoves,markdownDescription:o.kg("showMoves","Controls whether the diff editor should show detected code moves.")},"diffEditor.experimental.showEmptyDecorations":{type:"boolean",default:s.q.experimental.showEmptyDecorations,description:o.kg("showEmptyDecorations","Controls whether the diff editor shows empty decorations to see where characters got inserted or deleted.")},"diffEditor.experimental.useTrueInlineView":{type:"boolean",default:s.q.experimental.useTrueInlineView,description:o.kg("useTrueInlineView","If enabled and the editor uses the inline view, word changes are rendered inline.")}}};for(const f of n.BE){const e=f.schema;if("undefined"!==typeof e)if("undefined"!==typeof(d=e).type||"undefined"!==typeof d.anyOf)h.properties[`editor.${f.name}`]=e;else for(const t in e)Object.hasOwnProperty.call(e,t)&&(h.properties[t]=e[t])}var d;let u=null;function g(){return null===u&&(u=Object.create(null),Object.keys(h.properties).forEach((e=>{u[e]=!0}))),u}function p(e){return g()[`editor.${e}`]||!1}function m(e){return g()[`diffEditor.${e}`]||!1}c.O.as(a.Fd.Configuration).registerConfiguration(h)},94484:(e,t,i)=>{e.exports=i(64066)},94564:(e,t,i)=>{"use strict";i.d(t,{I:()=>h});var s=i(91508),n=i(1245),r=i(83069),o=i(36677),a=i(35817),c=i(32799);class l{constructor(e,t,i){this._cursorPositionBrand=void 0,this.lineNumber=e,this.column=t,this.leftoverVisibleColumns=i}}class h{static leftPosition(e,t){if(t.column>e.getLineMinColumn(t.lineNumber))return t.delta(void 0,-s.MV(e.getLineContent(t.lineNumber),t.column-1));if(t.lineNumber>1){const i=t.lineNumber-1;return new r.y(i,e.getLineMaxColumn(i))}return t}static leftPositionAtomicSoftTabs(e,t,i){if(t.column<=e.getLineIndentColumn(t.lineNumber)){const s=e.getLineMinColumn(t.lineNumber),n=e.getLineContent(t.lineNumber),o=a.s.atomicPosition(n,t.column-1,i,0);if(-1!==o&&o+1>=s)return new r.y(t.lineNumber,o+1)}return this.leftPosition(e,t)}static left(e,t,i){const s=e.stickyTabStops?h.leftPositionAtomicSoftTabs(t,i,e.tabSize):h.leftPosition(t,i);return new l(s.lineNumber,s.column,0)}static moveLeft(e,t,i,s,n){let r,o;if(i.hasSelection()&&!s)r=i.selection.startLineNumber,o=i.selection.startColumn;else{const s=i.position.delta(void 0,-(n-1)),a=t.normalizePosition(h.clipPositionColumn(s,t),0),c=h.left(e,t,a);r=c.lineNumber,o=c.column}return i.move(s,r,o,0)}static clipPositionColumn(e,t){return new r.y(e.lineNumber,h.clipRange(e.column,t.getLineMinColumn(e.lineNumber),t.getLineMaxColumn(e.lineNumber)))}static clipRange(e,t,i){return ei?i:e}static rightPosition(e,t,i){return iu?(i=u,s=c?t.getLineMaxColumn(i):Math.min(t.getLineMaxColumn(i),s)):s=e.columnFromVisibleColumn(t,i,d),o=m?0:d-n.A.visibleColumnFromColumn(t.getLineContent(i),s,e.tabSize),void 0!==h){const e=new r.y(i,s),n=t.normalizePosition(e,h);o+=s-n.column,i=n.lineNumber,s=n.column}return new l(i,s,o)}static down(e,t,i,s,n,r,o){return this.vertical(e,t,i,s,n,i+r,o,4)}static moveDown(e,t,i,s,n){let o,a;i.hasSelection()&&!s?(o=i.selection.endLineNumber,a=i.selection.endColumn):(o=i.position.lineNumber,a=i.position.column);let c,l=0;do{c=h.down(e,t,o+l,a,i.leftoverVisibleColumns,n,!0);if(t.normalizePosition(new r.y(c.lineNumber,c.column),2).lineNumber>o)break}while(l++<10&&o+l1&&this._isBlankLine(t,n);)n--;for(;n>1&&!this._isBlankLine(t,n);)n--;return i.move(s,n,t.getLineMinColumn(n),0)}static moveToNextBlankLine(e,t,i,s){const n=t.getLineCount();let r=i.position.lineNumber;for(;r{"use strict";i.d(t,{A:()=>a});var s,n,r=i(59284);function o(){return o=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{W:()=>o,c:()=>r});var s=i(36677),n=i(19131);class r{static fromModelContentChanges(e){return e.map((e=>{const t=s.Q.lift(e.range);return new r((0,n.VL)(t.getStartPosition()),(0,n.VL)(t.getEndPosition()),(0,n.rR)(e.text))})).reverse()}constructor(e,t,i){this.startOffset=e,this.endOffset=t,this.newLength=i}toString(){return`[${(0,n.l4)(this.startOffset)}...${(0,n.l4)(this.endOffset)}) -> ${(0,n.l4)(this.newLength)}`}}class o{constructor(e){this.nextEditIdx=0,this.deltaOldToNewLineCount=0,this.deltaOldToNewColumnCount=0,this.deltaLineIdxInOld=-1,this.edits=e.map((e=>a.from(e)))}getOffsetBeforeChange(e){return this.adjustNextEdit(e),this.translateCurToOld(e)}getDistanceToNextChange(e){this.adjustNextEdit(e);const t=this.edits[this.nextEditIdx],i=t?this.translateOldToCur(t.offsetObj):null;return null===i?null:(0,n.MS)(e,i)}translateOldToCur(e){return e.lineCount===this.deltaLineIdxInOld?(0,n.qe)(e.lineCount+this.deltaOldToNewLineCount,e.columnCount+this.deltaOldToNewColumnCount):(0,n.qe)(e.lineCount+this.deltaOldToNewLineCount,e.columnCount)}translateCurToOld(e){const t=(0,n.l4)(e);return t.lineCount-this.deltaOldToNewLineCount===this.deltaLineIdxInOld?(0,n.qe)(t.lineCount-this.deltaOldToNewLineCount,t.columnCount-this.deltaOldToNewColumnCount):(0,n.qe)(t.lineCount-this.deltaOldToNewLineCount,t.columnCount)}adjustNextEdit(e){for(;this.nextEditIdx{"use strict";i.d(t,{Hg:()=>p});var s,n=i(14718),r=i(63591),o=i(41234),a=i(78381),c=i(86571),l=i(87723),h=i(10920),d=i(90651),u=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};const p=(0,r.u1)("diffProviderFactoryService");let m=class{constructor(e){this.instantiationService=e}createDiffProvider(e){return this.instantiationService.createInstance(f,e)}};m=u([g(0,r._Y)],m),(0,n.v)(p,m,1);let f=class{static{s=this}static{this.diffCache=new Map}constructor(e,t,i){this.editorWorkerService=t,this.telemetryService=i,this.onDidChangeEventEmitter=new o.vl,this.onDidChange=this.onDidChangeEventEmitter.event,this.diffAlgorithm="advanced",this.diffAlgorithmOnDidChangeSubscription=void 0,this.setOptions(e)}dispose(){this.diffAlgorithmOnDidChangeSubscription?.dispose()}async computeDiff(e,t,i,n){if("string"!==typeof this.diffAlgorithm)return this.diffAlgorithm.computeDiff(e,t,i,n);if(e.isDisposed()||t.isDisposed())return{changes:[],identical:!0,quitEarly:!1,moves:[]};if(1===e.getLineCount()&&1===e.getLineMaxColumn(1))return 1===t.getLineCount()&&1===t.getLineMaxColumn(1)?{changes:[],identical:!0,quitEarly:!1,moves:[]}:{changes:[new l.wm(new c.M(1,2),new c.M(1,t.getLineCount()+1),[new l.q6(e.getFullModelRange(),t.getFullModelRange())])],identical:!1,quitEarly:!1,moves:[]};const r=JSON.stringify([e.uri.toString(),t.uri.toString()]),o=JSON.stringify([e.id,t.id,e.getAlternativeVersionId(),t.getAlternativeVersionId(),JSON.stringify(i)]),h=s.diffCache.get(r);if(h&&h.context===o)return h.result;const d=a.W.create(),u=await this.editorWorkerService.computeDiff(e.uri,t.uri,i,this.diffAlgorithm),g=d.elapsed();if(this.telemetryService.publicLog2("diffEditor.computeDiff",{timeMs:g,timedOut:u?.quitEarly??!0,detectedMoves:i.computeMoves?u?.moves.length??0:-1}),n.isCancellationRequested)return{changes:[],identical:!1,quitEarly:!0,moves:[]};if(!u)throw new Error("no diff result available");return s.diffCache.size>10&&s.diffCache.delete(s.diffCache.keys().next().value),s.diffCache.set(r,{result:u,context:o}),u}setOptions(e){let t=!1;e.diffAlgorithm&&this.diffAlgorithm!==e.diffAlgorithm&&(this.diffAlgorithmOnDidChangeSubscription?.dispose(),this.diffAlgorithmOnDidChangeSubscription=void 0,this.diffAlgorithm=e.diffAlgorithm,"string"!==typeof e.diffAlgorithm&&(this.diffAlgorithmOnDidChangeSubscription=e.diffAlgorithm.onDidChange((()=>this.onDidChangeEventEmitter.fire()))),t=!0),t&&this.onDidChangeEventEmitter.fire()}};f=s=u([g(1,h.IEditorWorkerService),g(2,d.k)],f)},94803:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"elixir",extensions:[".ex",".exs"],aliases:["Elixir","elixir","ex"],loader:()=>i.e(35382).then(i.bind(i,35382))})},94908:(e,t,i)=>{"use strict";var s=i(60413),n=i(8597),r=i(98067),o=i(68792),a=i(31450),c=i(80301),l=i(60002),h=i(55433),d=i(78209),u=i(27195),g=i(54770),p=i(32848);const m="9_cutcopypaste",f=r.ib||document.queryCommandSupported("cut"),_=r.ib||document.queryCommandSupported("copy"),v="undefined"!==typeof navigator.clipboard&&!s.gm||document.queryCommandSupported("paste");function C(e){return e.register(),e}const E=f?C(new a.fE({id:"editor.action.clipboardCutAction",precondition:void 0,kbOpts:r.ib?{primary:2102,win:{primary:2102,secondary:[1044]},weight:100}:void 0,menuOpts:[{menuId:u.D8.MenubarEditMenu,group:"2_ccp",title:d.kg({key:"miCut",comment:["&& denotes a mnemonic"]},"Cu&&t"),order:1},{menuId:u.D8.EditorContext,group:m,title:d.kg("actions.clipboard.cutLabel","Cut"),when:l.R.writable,order:1},{menuId:u.D8.CommandPalette,group:"",title:d.kg("actions.clipboard.cutLabel","Cut"),order:1},{menuId:u.D8.SimpleEditorContext,group:m,title:d.kg("actions.clipboard.cutLabel","Cut"),when:l.R.writable,order:1}]})):void 0,b=_?C(new a.fE({id:"editor.action.clipboardCopyAction",precondition:void 0,kbOpts:r.ib?{primary:2081,win:{primary:2081,secondary:[2067]},weight:100}:void 0,menuOpts:[{menuId:u.D8.MenubarEditMenu,group:"2_ccp",title:d.kg({key:"miCopy",comment:["&& denotes a mnemonic"]},"&&Copy"),order:2},{menuId:u.D8.EditorContext,group:m,title:d.kg("actions.clipboard.copyLabel","Copy"),order:2},{menuId:u.D8.CommandPalette,group:"",title:d.kg("actions.clipboard.copyLabel","Copy"),order:1},{menuId:u.D8.SimpleEditorContext,group:m,title:d.kg("actions.clipboard.copyLabel","Copy"),order:2}]})):void 0;u.ZG.appendMenuItem(u.D8.MenubarEditMenu,{submenu:u.D8.MenubarCopy,title:d.aS("copy as","Copy As"),group:"2_ccp",order:3}),u.ZG.appendMenuItem(u.D8.EditorContext,{submenu:u.D8.EditorContextCopy,title:d.aS("copy as","Copy As"),group:m,order:3}),u.ZG.appendMenuItem(u.D8.EditorContext,{submenu:u.D8.EditorContextShare,title:d.aS("share","Share"),group:"11_share",order:-1,when:p.M$.and(p.M$.notEquals("resourceScheme","output"),l.R.editorTextFocus)}),u.ZG.appendMenuItem(u.D8.ExplorerContext,{submenu:u.D8.ExplorerContextShare,title:d.aS("share","Share"),group:"11_share",order:-1});const S=v?C(new a.fE({id:"editor.action.clipboardPasteAction",precondition:void 0,kbOpts:r.ib?{primary:2100,win:{primary:2100,secondary:[1043]},linux:{primary:2100,secondary:[1043]},weight:100}:void 0,menuOpts:[{menuId:u.D8.MenubarEditMenu,group:"2_ccp",title:d.kg({key:"miPaste",comment:["&& denotes a mnemonic"]},"&&Paste"),order:4},{menuId:u.D8.EditorContext,group:m,title:d.kg("actions.clipboard.pasteLabel","Paste"),when:l.R.writable,order:4},{menuId:u.D8.CommandPalette,group:"",title:d.kg("actions.clipboard.pasteLabel","Paste"),order:1},{menuId:u.D8.SimpleEditorContext,group:m,title:d.kg("actions.clipboard.pasteLabel","Paste"),when:l.R.writable,order:4}]})):void 0;class y extends a.ks{constructor(){super({id:"editor.action.clipboardCopyWithSyntaxHighlightingAction",label:d.kg("actions.clipboard.copyWithSyntaxHighlightingLabel","Copy With Syntax Highlighting"),alias:"Copy With Syntax Highlighting",precondition:void 0,kbOpts:{kbExpr:l.R.textInputFocus,primary:0,weight:100}})}run(e,t){if(!t.hasModel())return;!t.getOption(37)&&t.getSelection().isEmpty()||(o.Eq.forceCopyWithSyntaxHighlighting=!0,t.focus(),t.getContainerDomNode().ownerDocument.execCommand("copy"),o.Eq.forceCopyWithSyntaxHighlighting=!1)}}function w(e,t){e&&(e.addImplementation(1e4,"code-editor",((e,i)=>{const s=e.get(c.T).getFocusedCodeEditor();if(s&&s.hasTextFocus()){const e=s.getOption(37),i=s.getSelection();return i&&i.isEmpty()&&!e||s.getContainerDomNode().ownerDocument.execCommand(t),!0}return!1})),e.addImplementation(0,"generic-dom",((e,i)=>((0,n.a)().execCommand(t),!0))))}w(E,"cut"),w(b,"copy"),S&&(S.addImplementation(1e4,"code-editor",((e,t)=>{const i=e.get(c.T),s=e.get(g.h),n=i.getFocusedCodeEditor();if(n&&n.hasTextFocus()){return n.getContainerDomNode().ownerDocument.execCommand("paste")?h.Rj.get(n)?.finishedPaste()??Promise.resolve():!r.HZ||(async()=>{const e=await s.readText();if(""!==e){const t=o.bs.INSTANCE.get(e);let i=!1,s=null,r=null;t&&(i=n.getOption(37)&&!!t.isFromEmptySelection,s="undefined"!==typeof t.multicursorText?t.multicursorText:null,r=t.mode),n.trigger("keyboard","paste",{text:e,pasteOnNewLine:i,multicursorText:s,mode:r})}})()}return!1})),S.addImplementation(0,"generic-dom",((e,t)=>((0,n.a)().execCommand("paste"),!0)))),_&&(0,a.Fl)(y)},94958:(e,t,i)=>{"use strict";let s;function n(e){s=e}function r(){return s}i.d(t,{Br:()=>n,jm:()=>o,tZ:()=>r});class o{constructor(){this.indentation=0,this.changedObservablesSets=new WeakMap}textToConsoleArgs(e){return function(e){const t=new Array,i=[];let s="";function n(e){if("length"in e)for(const t of e)t&&n(t);else"text"in e?(s+=`%c${e.text}`,t.push(e.style),e.data&&i.push(...e.data)):"data"in e&&i.push(...e.data)}n(e);const r=[s,...t];return r.push(...i),r}([a(d("| ",this.indentation)),e])}formatInfo(e){return e.hadValue?e.didChange?[a(" "),l(h(e.oldValue,70),{color:"red",strikeThrough:!0}),a(" "),l(h(e.newValue,60),{color:"green"})]:[a(" (unchanged)")]:[a(" "),l(h(e.newValue,60),{color:"green"}),a(" (initial)")]}handleObservableChanged(e,t){console.log(...this.textToConsoleArgs([c("observable value changed"),l(e.debugName,{color:"BlueViolet"}),...this.formatInfo(t)]))}formatChanges(e){if(0!==e.size)return l(" (changed deps: "+[...e].map((e=>e.debugName)).join(", ")+")",{color:"gray"})}handleDerivedCreated(e){const t=e.handleChange;this.changedObservablesSets.set(e,new Set),e.handleChange=(i,s)=>(this.changedObservablesSets.get(e).add(i),t.apply(e,[i,s]))}handleDerivedRecomputed(e,t){const i=this.changedObservablesSets.get(e);console.log(...this.textToConsoleArgs([c("derived recomputed"),l(e.debugName,{color:"BlueViolet"}),...this.formatInfo(t),this.formatChanges(i),{data:[{fn:e._debugNameData.referenceFn??e._computeFn}]}])),i.clear()}handleFromEventObservableTriggered(e,t){console.log(...this.textToConsoleArgs([c("observable from event triggered"),l(e.debugName,{color:"BlueViolet"}),...this.formatInfo(t),{data:[{fn:e._getValue}]}]))}handleAutorunCreated(e){const t=e.handleChange;this.changedObservablesSets.set(e,new Set),e.handleChange=(i,s)=>(this.changedObservablesSets.get(e).add(i),t.apply(e,[i,s]))}handleAutorunTriggered(e){const t=this.changedObservablesSets.get(e);console.log(...this.textToConsoleArgs([c("autorun"),l(e.debugName,{color:"BlueViolet"}),this.formatChanges(t),{data:[{fn:e._debugNameData.referenceFn??e._runFn}]}])),t.clear(),this.indentation++}handleAutorunFinished(e){this.indentation--}handleBeginTransaction(e){let t=e.getDebugName();void 0===t&&(t=""),console.log(...this.textToConsoleArgs([c("transaction"),l(t,{color:"BlueViolet"}),{data:[{fn:e._fn}]}])),this.indentation++}handleEndTransaction(){this.indentation--}}function a(e){return l(e,{color:"black"})}function c(e){return l(function(e,t){for(;e.length`${e}${t}:${i};`),""))};var s}function h(e,t){switch(typeof e){case"number":default:return""+e;case"string":return e.length+2<=t?`"${e}"`:`"${e.substr(0,t-7)}"+...`;case"boolean":return e?"true":"false";case"undefined":return"undefined";case"object":return null===e?"null":Array.isArray(e)?function(e,t){let i="[ ",s=!0;for(const n of e){if(s||(i+=", "),i.length-5>t){i+="...";break}s=!1,i+=`${h(n,t-i.length)}`}return i+=" ]",i}(e,t):function(e,t){let i="{ ",s=!0;for(const[n,r]of Object.entries(e)){if(s||(i+=", "),i.length-5>t){i+="...";break}s=!1,i+=`${n}: ${h(r,t-i.length)}`}return i+=" }",i}(e,t);case"symbol":return e.toString();case"function":return`[[Function${e.name?" "+e.name:""}]]`}}function d(e,t){let i="";for(let s=1;s<=t;s++)i+=e;return i}},95200:(e,t,i)=>{"use strict";var s=i(5662),n=i(31450);class r extends s.jG{static{this.ID="editor.contrib.longLinesHelper"}constructor(e){super(),this._editor=e,this._register(this._editor.onMouseDown((e=>{const t=this._editor.getOption(118);t>=0&&6===e.target.type&&e.target.position.column>=t&&this._editor.updateOptions({stopRenderingLineAfter:-1})})))}}(0,n.HW)(r.ID,r,2)},96032:(e,t,i)=>{"use strict";i.d(t,{n:()=>s,r:()=>n});class s{constructor(e){this._prefix=e,this._lastId=0}nextId(){return this._prefix+ ++this._lastId}}const n=new s("id#")},96282:(e,t,i)=>{"use strict";i.d(t,{Z:()=>s});const s=new class{constructor(){this._implementations=[]}register(e){return this._implementations.push(e),{dispose:()=>{const t=this._implementations.indexOf(e);-1!==t&&this._implementations.splice(t,1)}}}getImplementations(){return this._implementations}}},96299:(e,t,i)=>{"use strict";i.d(t,{Y:()=>k});var s,n=i(90766),r=i(18447),o=i(64383),a=i(41234),c=i(5662),l=i(91508),h=i(75326),d=i(10920),u=i(14055),g=i(54770),p=i(84001),m=i(32848),f=i(18801),_=i(90651),v=i(51173),C=i(48116),E=i(56942),b=i(26690),S=i(631),y=i(62051),w=i(30936),R=i(97035),L=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},T=function(e,t){return function(i,s){t(i,s,e)}};class x{static shouldAutoTrigger(e){if(!e.hasModel())return!1;const t=e.getModel(),i=e.getPosition();t.tokenization.tokenizeIfCheap(i.lineNumber);const s=t.getWordAtPosition(i);return!!s&&((s.endColumn===i.column||s.startColumn+1===i.column)&&!!isNaN(Number(s.word)))}constructor(e,t,i){this.leadingLineContent=e.getLineContent(t.lineNumber).substr(0,t.column-1),this.leadingWord=e.getWordUntilPosition(t),this.lineNumber=t.lineNumber,this.column=t.column,this.triggerOptions=i}}let k=s=class{constructor(e,t,i,s,r,o,l,d,u){this._editor=e,this._editorWorkerService=t,this._clipboardService=i,this._telemetryService=s,this._logService=r,this._contextKeyService=o,this._configurationService=l,this._languageFeaturesService=d,this._envService=u,this._toDispose=new c.Cm,this._triggerCharacterListener=new c.Cm,this._triggerQuickSuggest=new n.pc,this._triggerState=void 0,this._completionDisposables=new c.Cm,this._onDidCancel=new a.vl,this._onDidTrigger=new a.vl,this._onDidSuggest=new a.vl,this.onDidCancel=this._onDidCancel.event,this.onDidTrigger=this._onDidTrigger.event,this.onDidSuggest=this._onDidSuggest.event,this._telemetryGate=0,this._currentSelection=this._editor.getSelection()||new h.L(1,1,1,1),this._toDispose.add(this._editor.onDidChangeModel((()=>{this._updateTriggerCharacters(),this.cancel()}))),this._toDispose.add(this._editor.onDidChangeModelLanguage((()=>{this._updateTriggerCharacters(),this.cancel()}))),this._toDispose.add(this._editor.onDidChangeConfiguration((()=>{this._updateTriggerCharacters()}))),this._toDispose.add(this._languageFeaturesService.completionProvider.onDidChange((()=>{this._updateTriggerCharacters(),this._updateActiveSuggestSession()})));let g=!1;this._toDispose.add(this._editor.onDidCompositionStart((()=>{g=!0}))),this._toDispose.add(this._editor.onDidCompositionEnd((()=>{g=!1,this._onCompositionEnd()}))),this._toDispose.add(this._editor.onDidChangeCursorSelection((e=>{g||this._onCursorChange(e)}))),this._toDispose.add(this._editor.onDidChangeModelContent((()=>{g||void 0===this._triggerState||this._refilterCompletionItems()}))),this._updateTriggerCharacters()}dispose(){(0,c.AS)(this._triggerCharacterListener),(0,c.AS)([this._onDidCancel,this._onDidSuggest,this._onDidTrigger,this._triggerQuickSuggest]),this._toDispose.dispose(),this._completionDisposables.dispose(),this.cancel()}_updateTriggerCharacters(){if(this._triggerCharacterListener.clear(),this._editor.getOption(92)||!this._editor.hasModel()||!this._editor.getOption(122))return;const e=new Map;for(const i of this._languageFeaturesService.completionProvider.all(this._editor.getModel()))for(const t of i.triggerCharacters||[]){let s=e.get(t);if(!s){s=new Set;const i=(0,C.f3)();i&&s.add(i),e.set(t,s)}s.add(i)}const t=t=>{if(!function(e,t){if(!Boolean(t.getContextKeyValue("inlineSuggestionVisible")))return!0;const i=t.getContextKeyValue(y.p.suppressSuggestions.key);return void 0!==i?!i:!e.getOption(62).suppressSuggestions}(this._editor,this._contextKeyService,this._configurationService))return;if(x.shouldAutoTrigger(this._editor))return;if(!t){const e=this._editor.getPosition();t=this._editor.getModel().getLineContent(e.lineNumber).substr(0,e.column-1)}let i="";(0,l.LJ)(t.charCodeAt(t.length-1))?(0,l.pc)(t.charCodeAt(t.length-2))&&(i=t.substr(t.length-2)):i=t.charAt(t.length-1);const s=e.get(i);if(s){const e=new Map;if(this._completionModel)for(const[t,i]of this._completionModel.getItemsByProvider())s.has(t)||e.set(t,i);this.trigger({auto:!0,triggerKind:1,triggerCharacter:i,retrigger:Boolean(this._completionModel),clipboardText:this._completionModel?.clipboardText,completionOptions:{providerFilter:s,providerItemsToReuse:e}})}};this._triggerCharacterListener.add(this._editor.onDidType(t)),this._triggerCharacterListener.add(this._editor.onDidCompositionEnd((()=>t())))}get state(){return this._triggerState?this._triggerState.auto?2:1:0}cancel(e=!1){void 0!==this._triggerState&&(this._triggerQuickSuggest.cancel(),this._requestToken?.cancel(),this._requestToken=void 0,this._triggerState=void 0,this._completionModel=void 0,this._context=void 0,this._onDidCancel.fire({retrigger:e}))}clear(){this._completionDisposables.clear()}_updateActiveSuggestSession(){void 0!==this._triggerState&&(this._editor.hasModel()&&this._languageFeaturesService.completionProvider.has(this._editor.getModel())?this.trigger({auto:this._triggerState.auto,retrigger:!0}):this.cancel())}_onCursorChange(e){if(!this._editor.hasModel())return;const t=this._currentSelection;this._currentSelection=this._editor.getSelection(),!e.selection.isEmpty()||0!==e.reason&&3!==e.reason||"keyboard"!==e.source&&"deleteLeft"!==e.source?this.cancel():void 0===this._triggerState&&0===e.reason?(t.containsRange(this._currentSelection)||t.getEndPosition().isBeforeOrEqual(this._currentSelection.getPosition()))&&this._doTriggerQuickSuggest():void 0!==this._triggerState&&3===e.reason&&this._refilterCompletionItems()}_onCompositionEnd(){void 0===this._triggerState?this._doTriggerQuickSuggest():this._refilterCompletionItems()}_doTriggerQuickSuggest(){C.r3.isAllOff(this._editor.getOption(90))||this._editor.getOption(119).snippetsPreventQuickSuggestions&&w.O.get(this._editor)?.isInSnippet()||(this.cancel(),this._triggerQuickSuggest.cancelAndSet((()=>{if(void 0!==this._triggerState)return;if(!x.shouldAutoTrigger(this._editor))return;if(!this._editor.hasModel()||!this._editor.hasWidgetFocus())return;const e=this._editor.getModel(),t=this._editor.getPosition(),i=this._editor.getOption(90);if(!C.r3.isAllOff(i)){if(!C.r3.isAllOn(i)){e.tokenization.tokenizeIfCheap(t.lineNumber);const s=e.tokenization.getLineTokens(t.lineNumber),n=s.getStandardTokenType(s.findTokenIndexAtOffset(Math.max(t.column-1-1,0)));if("on"!==C.r3.valueFor(i,n))return}(function(e,t){if(!Boolean(t.getContextKeyValue(y.p.inlineSuggestionVisible.key)))return!0;const i=t.getContextKeyValue(y.p.suppressSuggestions.key);return void 0!==i?!i:!e.getOption(62).suppressSuggestions})(this._editor,this._contextKeyService,this._configurationService)&&this._languageFeaturesService.completionProvider.has(e)&&this.trigger({auto:!0})}}),this._editor.getOption(91)))}_refilterCompletionItems(){(0,S.j)(this._editor.hasModel()),(0,S.j)(void 0!==this._triggerState);const e=this._editor.getModel(),t=this._editor.getPosition(),i=new x(e,t,{...this._triggerState,refilter:!0});this._onNewContext(i)}trigger(e){if(!this._editor.hasModel())return;const t=this._editor.getModel(),i=new x(t,this._editor.getPosition(),e);this.cancel(e.retrigger),this._triggerState=e,this._onDidTrigger.fire({auto:e.auto,shy:e.shy??!1,position:this._editor.getPosition()}),this._context=i;let n={triggerKind:e.triggerKind??0};e.triggerCharacter&&(n={triggerKind:1,triggerCharacter:e.triggerCharacter}),this._requestToken=new r.Qi;let a=1;switch(this._editor.getOption(113)){case"top":a=0;break;case"bottom":a=2}const{itemKind:c,showDeprecated:l}=s.createSuggestFilter(this._editor),h=new C.l1(a,e.completionOptions?.kindFilter??c,e.completionOptions?.providerFilter,e.completionOptions?.providerItemsToReuse,l),d=u.S.create(this._editorWorkerService,this._editor),g=(0,C.aR)(this._languageFeaturesService.completionProvider,t,this._editor.getPosition(),h,n,this._requestToken.token);Promise.all([g,d]).then((async([t,i])=>{if(this._requestToken?.dispose(),!this._editor.hasModel())return;let s=e?.clipboardText;if(!s&&t.needsClipboard&&(s=await this._clipboardService.readText()),void 0===this._triggerState)return;const n=this._editor.getModel(),r=new x(n,this._editor.getPosition(),e),o={...b.Nd.default,firstMatchCanBeWeak:!this._editor.getOption(119).matchOnWordStartOnly};if(this._completionModel=new v.C(t.items,this._context.column,{leadingLineContent:r.leadingLineContent,characterCountDelta:r.column-this._context.column},i,this._editor.getOption(119),this._editor.getOption(113),o,s),this._completionDisposables.add(t.disposable),this._onNewContext(r),this._reportDurationsTelemetry(t.durations),!this._envService.isBuilt||this._envService.isExtensionDevelopment)for(const e of t.items)e.isInvalid&&this._logService.warn(`[suggest] did IGNORE invalid completion item from ${e.provider._debugDisplayName}`,e.completion)})).catch(o.dz)}_reportDurationsTelemetry(e){this._telemetryGate++%230===0&&setTimeout((()=>{this._telemetryService.publicLog2("suggest.durations.json",{data:JSON.stringify(e)}),this._logService.debug("suggest.durations.json",e)}))}static createSuggestFilter(e){const t=new Set;"none"===e.getOption(113)&&t.add(27);const i=e.getOption(119);return i.showMethods||t.add(0),i.showFunctions||t.add(1),i.showConstructors||t.add(2),i.showFields||t.add(3),i.showVariables||t.add(4),i.showClasses||t.add(5),i.showStructs||t.add(6),i.showInterfaces||t.add(7),i.showModules||t.add(8),i.showProperties||t.add(9),i.showEvents||t.add(10),i.showOperators||t.add(11),i.showUnits||t.add(12),i.showValues||t.add(13),i.showConstants||t.add(14),i.showEnums||t.add(15),i.showEnumMembers||t.add(16),i.showKeywords||t.add(17),i.showWords||t.add(18),i.showColors||t.add(19),i.showFiles||t.add(20),i.showReferences||t.add(21),i.showColors||t.add(22),i.showFolders||t.add(23),i.showTypeParameters||t.add(24),i.showSnippets||t.add(27),i.showUsers||t.add(25),i.showIssues||t.add(26),{itemKind:t,showDeprecated:i.showDeprecated}}_onNewContext(e){if(this._context)if(e.lineNumber===this._context.lineNumber)if((0,l.UU)(e.leadingLineContent)===(0,l.UU)(this._context.leadingLineContent)){if(e.columnthis._context.leadingWord.startColumn){if(x.shouldAutoTrigger(this._editor)&&this._context){const e=this._completionModel.getItemsByProvider();this.trigger({auto:this._context.triggerOptions.auto,retrigger:!0,clipboardText:this._completionModel.clipboardText,completionOptions:{providerItemsToReuse:e}})}}else if(e.column>this._context.column&&this._completionModel.getIncompleteProvider().size>0&&0!==e.leadingWord.word.length){const e=new Map,t=new Set;for(const[i,s]of this._completionModel.getItemsByProvider())s.length>0&&s[0].container.incomplete?t.add(i):e.set(i,s);this.trigger({auto:this._context.triggerOptions.auto,triggerKind:2,retrigger:!0,clipboardText:this._completionModel.clipboardText,completionOptions:{providerFilter:t,providerItemsToReuse:e}})}else{const t=this._completionModel.lineContext;let i=!1;if(this._completionModel.lineContext={leadingLineContent:e.leadingLineContent,characterCountDelta:e.column-this._context.column},0===this._completionModel.items.length){const s=x.shouldAutoTrigger(this._editor);if(!this._context)return void this.cancel();if(s&&this._context.leadingWord.endColumn0,i&&0===e.leadingWord.word.length)return void this.cancel()}this._onDidSuggest.fire({completionModel:this._completionModel,triggerOptions:e.triggerOptions,isFrozen:i})}}else this.cancel();else this.cancel()}};k=s=L([T(1,d.IEditorWorkerService),T(2,g.h),T(3,_.k),T(4,f.rr),T(5,m.fN),T(6,p.pG),T(7,E.ILanguageFeaturesService),T(8,R.k)],k)},96409:(e,t,i)=>{e.exports=function(){const e=i(94297);function t(t,i){return t.$binary?i.binaryAsHex?e.escapeYQLBinaryString(i,t.$value):atob(t.$value):i.escapeYQLStrings?e.escapeJSONString(i,t.$value):e.escapeHTMLString(i,t.$value)}return t.isScalar=!0,t}},96589:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 6.5a2 2 0 1 0 0-4 2 2 0 0 0 0 4M8 8a3.5 3.5 0 1 0 0-7 3.5 3.5 0 0 0 0 7m1 1.225a.71.71 0 0 0-.679-.72A11 11 0 0 0 8 8.5c-3.85 0-7 2-7 4A2.5 2.5 0 0 0 3.5 15h2.25a.75.75 0 0 0 0-1.5H3.5a1 1 0 0 1-1-1c0-.204.22-.809 1.32-1.459C4.838 10.44 6.32 10 8 10q.088 0 .175.002c.442.008.825-.335.825-.777m3.59.307c.434.102.776.444.879.878l-2.823 2.822a1.5 1.5 0 0 1-.848.425l-.53.075.075-.53a1.5 1.5 0 0 1 .425-.848zm-.883 4.76 3.068-3.067a.77.77 0 0 0 .225-.543A2.683 2.683 0 0 0 12.318 8a.77.77 0 0 0-.543.224l-3.068 3.069a3 3 0 0 0-.848 1.697l-.17 1.19a1 1 0 0 0 1.13 1.131l1.191-.17a3 3 0 0 0 1.697-.848",clipRule:"evenodd"}))},96716:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sb",extensions:[".sb"],aliases:["Small Basic","sb"],loader:()=>i.e(57946).then(i.bind(i,57946))})},96758:(e,t,i)=>{"use strict";i.d(t,{E:()=>L});var s,n=i(8597),r=i(25154),o=i(10350),a=i(41234),c=i(5662),l=i(25689),h=i(16223),d=i(87289),u=i(78049),g=i(55130),p=i(78209),m=i(98031),f=i(61394),_=i(36677),v=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},C=function(e,t){return function(i,s){t(i,s,e)}};const E=(0,f.pU)("gutter-lightbulb",o.W.lightBulb,p.kg("gutterLightbulbWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor.")),b=(0,f.pU)("gutter-lightbulb-auto-fix",o.W.lightbulbAutofix,p.kg("gutterLightbulbAutoFixWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and a quick fix is available.")),S=(0,f.pU)("gutter-lightbulb-sparkle",o.W.lightbulbSparkle,p.kg("gutterLightbulbAIFixWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and an AI fix is available.")),y=(0,f.pU)("gutter-lightbulb-aifix-auto-fix",o.W.lightbulbSparkleAutofix,p.kg("gutterLightbulbAIFixAutoFixWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and an AI fix and a quick fix is available.")),w=(0,f.pU)("gutter-lightbulb-sparkle-filled",o.W.sparkleFilled,p.kg("gutterLightbulbSparkleFilledWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and an AI fix and a quick fix is available."));var R;!function(e){e.Hidden={type:0};e.Showing=class{constructor(e,t,i,s){this.actions=e,this.trigger=t,this.editorPosition=i,this.widgetPosition=s,this.type=1}}}(R||(R={}));let L=class extends c.jG{static{s=this}static{this.GUTTER_DECORATION=d.kI.register({description:"codicon-gutter-lightbulb-decoration",glyphMarginClassName:l.L.asClassName(o.W.lightBulb),glyphMargin:{position:h.ZS.Left},stickiness:1})}static{this.ID="editor.contrib.lightbulbWidget"}static{this._posPref=[0]}constructor(e,t){super(),this._editor=e,this._keybindingService=t,this._onClick=this._register(new a.vl),this.onClick=this._onClick.event,this._state=R.Hidden,this._gutterState=R.Hidden,this._iconClasses=[],this.lightbulbClasses=["codicon-"+E.id,"codicon-"+y.id,"codicon-"+b.id,"codicon-"+S.id,"codicon-"+w.id],this.gutterDecoration=s.GUTTER_DECORATION,this._domNode=n.$("div.lightBulbWidget"),this._domNode.role="listbox",this._register(r.q.ignoreTarget(this._domNode)),this._editor.addContentWidget(this),this._register(this._editor.onDidChangeModelContent((e=>{const t=this._editor.getModel();(1!==this.state.type||!t||this.state.editorPosition.lineNumber>=t.getLineCount())&&this.hide(),(1!==this.gutterState.type||!t||this.gutterState.editorPosition.lineNumber>=t.getLineCount())&&this.gutterHide()}))),this._register(n.Xc(this._domNode,(e=>{if(1!==this.state.type)return;this._editor.focus(),e.preventDefault();const{top:t,height:i}=n.BK(this._domNode),s=this._editor.getOption(67);let r=Math.floor(s/3);null!==this.state.widgetPosition.position&&this.state.widgetPosition.position.lineNumber{1===(1&e.buttons)&&this.hide()}))),this._register(a.Jh.runAndSubscribe(this._keybindingService.onDidUpdateKeybindings,(()=>{this._preferredKbLabel=this._keybindingService.lookupKeybinding(g.pR)?.getLabel()??void 0,this._quickFixKbLabel=this._keybindingService.lookupKeybinding(g.pQ)?.getLabel()??void 0,this._updateLightBulbTitleAndIcon()}))),this._register(this._editor.onMouseDown((async e=>{if(!e.target.element||!this.lightbulbClasses.some((t=>e.target.element&&e.target.element.classList.contains(t))))return;if(1!==this.gutterState.type)return;this._editor.focus();const{top:t,height:i}=n.BK(e.target.element),s=this._editor.getOption(67);let r=Math.floor(s/3);null!==this.gutterState.widgetPosition.position&&this.gutterState.widgetPosition.position.lineNumber22,g=e=>e>2&&this._editor.getTopForLineNumber(e)===this._editor.getTopForLineNumber(e-1),p=this._editor.getLineDecorations(r);let m=!1;if(p)for(const s of p){const e=s.options.glyphMarginClassName;if(e&&!this.lightbulbClasses.some((t=>e.includes(t)))){m=!0;break}}let f=r,_=1;if(!d){const a=e=>{const t=n.getLineContent(e);return/^\s*$|^\s+/.test(t)||t.length<=_};if(r>1&&!g(r-1)){const o=r===n.getLineCount(),c=r>1&&a(r-1),l=!o&&a(r+1),h=a(r),d=!l&&!c;if(!(l||c||m))return this.gutterState=new R.Showing(e,t,i,{position:{lineNumber:f,column:_},preference:s._posPref}),this.renderGutterLightbub(),this.hide();c||o||c&&!h?f-=1:(l||d&&h)&&(f+=1)}else if(1!==r||r!==n.getLineCount()&&(a(r+1)||a(r))){if(r{this._gutterDecorationID=t.addDecoration(new _.Q(e,0,e,0),this.gutterDecoration)}))}_removeGutterDecoration(e){this._editor.changeDecorations((t=>{t.removeDecoration(e),this._gutterDecorationID=void 0}))}_updateGutterDecoration(e,t){this._editor.changeDecorations((i=>{i.changeDecoration(e,new _.Q(t,0,t,0)),i.changeDecorationOptions(e,this.gutterDecoration)}))}_updateLightbulbTitle(e,t){1===this.state.type&&(t?this.title=p.kg("codeActionAutoRun","Run: {0}",this.state.actions.validActions[0].action.title):e&&this._preferredKbLabel?this.title=p.kg("preferredcodeActionWithKb","Show Code Actions. Preferred Quick Fix Available ({0})",this._preferredKbLabel):!e&&this._quickFixKbLabel?this.title=p.kg("codeActionWithKb","Show Code Actions ({0})",this._quickFixKbLabel):e||(this.title=p.kg("codeAction","Show Code Actions")))}set title(e){this._domNode.title=e}};L=s=v([C(1,m.b)],L)},97035:(e,t,i)=>{"use strict";i.d(t,{k:()=>s});const s=(0,i(63591).u1)("environmentService")},97144:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"postiats",extensions:[".dats",".sats",".hats"],aliases:["ATS","ATS/Postiats"],loader:()=>i.e(49582).then(i.bind(i,49582))})},97218:(e,t,i)=>{"use strict";i.d(t,{x:()=>Fe});var s=i(60712),n=i(59284);const r=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("g",{clipPath:"url(#a)"},n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M4.312 4.29a.764.764 0 0 1 1.103-.62.75.75 0 1 0 .67-1.34 2.264 2.264 0 0 0-3.268 1.836L2.706 5.5H1.75a.75.75 0 0 0 0 1.5h.83l-.392 4.71a.764.764 0 0 1-1.103.62.75.75 0 0 0-.67 1.34 2.264 2.264 0 0 0 3.268-1.836L4.086 7H5.25a.75.75 0 1 0 0-1.5H4.21zm6.014 2.23a.75.75 0 0 0-1.152.96l.85 1.02-.85 1.02a.75.75 0 0 0 1.152.96L11 9.672l.674.808a.75.75 0 0 0 1.152-.96l-.85-1.02.85-1.02a.75.75 0 0 0-1.152-.96L11 7.328zM8.02 4.55a.75.75 0 0 1 .43.969l-.145.378a7.25 7.25 0 0 0 0 5.205l.145.378a.75.75 0 0 1-1.4.539l-.145-.378a8.75 8.75 0 0 1 0-6.282l.145-.378a.75.75 0 0 1 .97-.431m5.961 0a.75.75 0 0 1 .97.43l.145.379a8.75 8.75 0 0 1 0 6.282l-.146.378a.75.75 0 1 1-1.4-.538l.146-.379a7.25 7.25 0 0 0 0-5.205l-.146-.378a.75.75 0 0 1 .431-.97",clipRule:"evenodd"})),n.createElement("defs",null,n.createElement("clipPath",{id:"a"},n.createElement("path",{fill:"currentColor",d:"M0 0h16v16H0z"}))));var o=i(20295);const a=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.5 8a5.5 5.5 0 1 1-11 0 5.5 5.5 0 0 1 11 0M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0M8.75 4.5a.75.75 0 0 0-1.5 0V8a.75.75 0 0 0 .3.6l2 1.5a.75.75 0 1 0 .9-1.2l-1.7-1.275z",clipRule:"evenodd"}));var c=i(32084),l=i(46819),h=i(28664),d=i(84476),u=i(99991),g=i(39238),p=i(69418),m=i(9187),f=i(38602),_=i(33705),v=i(14750);function C({placeholderValue:e,timeZone:t}){return null!==e&&void 0!==e?e:(0,v.KQ)({timeZone:t}).set("hour",0).set("minute",0).set("second",0)}function E(e,t,i){return t&&e.isBefore(t)?t:i&&i.isBefore(e)?i:e}function b(e,t){return e.set("hours",t.hour()).set("minutes",t.minute()).set("seconds",t.second())}function S(e,t,i){return(0,v.KQ)({input:e,timeZone:i}).format(t)}function y(e,t){const i=n.useRef(null),s=t.isCellFocused(e);n.useEffect((()=>{var e;s&&(null===(e=i.current)||void 0===e||e.focus({preventScroll:!0}))}),[s]);const r=t.focusedDate.isSame(e,t.mode)?0:-1,o=t.isCellDisabled(e),a=t.isSelected(e),c="highlightedRange"in t&&t.highlightedRange,l=Boolean(c&&a),h=a&&c&&e.isSame(c.start,t.mode),d=a&&c&&e.isSame(c.end,t.mode),u="days"===t.mode&&!t.focusedDate.isSame(e,"month"),g=t.isCellUnavailable(e),p=!o&&!g,m=t.isCurrent(e),f=t.isWeekend(e),_=function(e,t){switch(t.mode){case"days":return`${S(e,"dddd",t.timeZone)}, ${S(e,"LL",t.timeZone)}`;case"months":return`${S(e,"MMMM YYYY",t.timeZone)}`;case"quarters":return`${S(e,"[Q]Q YYYY",t.timeZone)}`;case"years":return`${S(e,"YYYY",t.timeZone)}`;default:return""}}(e,t),v={role:"gridcell","aria-selected":a?"true":void 0,"aria-disabled":o?"true":void 0},C={ref:i,role:"button",tabIndex:o?void 0:r,"aria-disabled":p?void 0:"true","aria-label":_,onClick:p?()=>{t.setFocusedDate(e),t.selectDate(e)}:void 0,onPointerEnter(){if("highlightDate"in t&&p)if(u){const i=e.isBefore(t.focusedDate)?t.focusedDate.startOf("month"):t.focusedDate.endOf("month").startOf("date");t.highlightDate(i)}else t.highlightDate(e)}};let E=S(e,"D",t.timeZone);return"months"===t.mode?E=S(e,"MMM",t.timeZone):"quarters"===t.mode?E=S(e,"[Q]Q",t.timeZone):"years"===t.mode&&(E=S(e,"YYYY",t.timeZone)),{cellProps:v,buttonProps:C,formattedDate:E,isDisabled:o,isSelected:a,isRangeSelection:l,isSelectionStart:h,isSelectionEnd:d,isOutsideCurrentRange:u,isUnavailable:g,isCurrent:m,isWeekend:f}}var w=i(51301);var R=i(72837);const L=JSON.parse('{"Previous":"Previous","Next":"Next","Switch to months view":"Switch to months view","Switch to quarters view":"Switch to quarters view","Switch to years view":"Switch to years view"}'),T=JSON.parse('{"Previous":"\u041d\u0430\u0437\u0430\u0434","Next":"\u0412\u043f\u0435\u0440\u0451\u0434","Switch to months view":"\u041f\u0435\u0440\u0435\u043a\u043b\u044e\u0447\u0438\u0442\u044c\u0441\u044f \u043d\u0430 \u043f\u0440\u043e\u0441\u043c\u043e\u0442\u0440 \u043f\u043e \u043c\u0435\u0441\u044f\u0446\u0430\u043c","Switch to quarters view":"\u041f\u0435\u0440\u0435\u043a\u043b\u044e\u0447\u0438\u0442\u044c\u0441\u044f \u043d\u0430 \u043f\u0440\u043e\u0441\u043c\u043e\u0442\u0440 \u043f\u043e \u043a\u0432\u0430\u0440\u0442\u0430\u043b\u0430\u043c","Switch to years view":"\u041f\u0435\u0440\u0435\u043a\u043b\u044e\u0447\u0438\u0442\u044c\u0441\u044f \u043d\u0430 \u043f\u0440\u043e\u0441\u043c\u043e\u0442\u0440 \u043f\u043e \u0433\u043e\u0434\u0430\u043c"}'),x=(0,R.N)({en:L,ru:T},`${p.C}calendar`),k="yc-button_disabled g-button_disabled";function A(e,t){const i=t.indexOf(e)+1;if(i===t.length)return;return{days:"",months:x("Switch to months view"),quarters:x("Switch to quarters view"),years:x("Switch to years view")}[t[i]]}const N=["days","months","quarters","years"],I=(0,p.o)("calendar"),O=n.forwardRef((function(e,t){const{state:i}=e,{calendarProps:r,modeButtonProps:o,nextButtonProps:a,previousButtonProps:c}=function(e,t){const i="years"===t.mode||"quarters"===t.mode?`${t.startDate.year()} \u2014 ${t.endDate.year()}`:S(t.focusedDate,"days"===t.mode?"MMMM YYYY":"YYYY",t.timeZone),{focusWithinProps:s}=(0,w.R)({onFocusWithin:e.onFocus,onBlurWithin:e.onBlur}),r=Object.assign({role:"group",id:e.id,"aria-label":[e["aria-label"],i].filter(Boolean).join(", "),"aria-labelledby":e["aria-labelledby"]||void 0,"aria-describedby":e["aria-describedby"]||void 0,"aria-details":e["aria-details"]||void 0,"aria-disabled":t.disabled||void 0},s),o=t.availableModes.indexOf(t.mode),a=o+1===t.availableModes.length,c=o+2===t.availableModes.length,l=t.disabled||a,h={disabled:t.disabled,className:l?k:void 0,onClick:l?void 0:()=>{t.zoomOut(),c&&t.setFocused(!0)},extraProps:{"aria-disabled":l?"true":void 0,"aria-description":A(t.mode,t.availableModes),"aria-live":"polite"},children:i},d=n.useRef(!1),u=t.disabled||t.isPreviousPageInvalid();n.useLayoutEffect((()=>{u&&d.current&&(d.current=!1,t.setFocused(!0))}));const g={disabled:t.disabled,className:u?k:void 0,onClick:u?void 0:()=>{t.focusPreviousPage()},onFocus:u?void 0:()=>{d.current=!0},onBlur:u?void 0:()=>{d.current=!1},extraProps:{"aria-label":x("Previous"),"aria-disabled":u?"true":void 0}},p=n.useRef(!1),m=t.disabled||t.isNextPageInvalid();return n.useLayoutEffect((()=>{m&&p.current&&(p.current=!1,t.setFocused(!0))})),{calendarProps:r,modeButtonProps:h,nextButtonProps:{disabled:t.disabled,className:m?k:void 0,onClick:m?void 0:()=>{t.focusNextPage()},onFocus:m?void 0:()=>{p.current=!0},onBlur:m?void 0:()=>{p.current=!1},extraProps:{"aria-label":x("Next"),"aria-disabled":u?"true":void 0}},previousButtonProps:g}}(e,i);return n.useImperativeHandle(t,(()=>({focus(){i.setFocused(!0)}}))),(0,s.jsxs)("div",Object.assign({},r,{className:I({size:e.size}),children:[(0,s.jsxs)("div",{className:I("header"),children:[(0,s.jsx)(d.$,Object.assign({},o,{view:"flat",size:e.size,children:i.availableModes.indexOf(i.mode)+1===i.availableModes.length?(0,s.jsx)("span",{className:I("mode-label",I("years-label")),children:o.children},"label"):[(0,s.jsx)("span",{className:I("mode-label"),children:o.children},"label"),(0,s.jsx)(d.$.Icon,{children:(0,s.jsx)(_.I,{direction:"bottom"})},"icon")]})),(0,s.jsxs)("div",{className:I("controls"),children:[(0,s.jsx)(d.$,Object.assign({},c,{view:"flat",size:e.size,children:(0,s.jsx)(d.$.Icon,{children:(0,s.jsx)(m.A,{className:I("control-icon")})})})),(0,s.jsx)(d.$,Object.assign({},a,{view:"flat",size:e.size,children:(0,s.jsx)(d.$.Icon,{children:(0,s.jsx)(f.A,{className:I("control-icon")})})}))]})]}),(0,s.jsx)(D,{state:i})]}))}));function D({state:e}){const[t,i]=n.useState((()=>Object.assign(Object.assign({},e),{isFocused:!1}))),r=e.mode!==t.mode,o=!e.startDate.isSame(t.startDate,"days");let a;r?a=N.indexOf(t.mode)>N.indexOf(e.mode)?"zoom-out":"zoom-in":o&&(a=e.startDate.isBefore(t.startDate)?"forward":"backward");const{gridProps:c}=function(e){const{focusWithinProps:t}=(0,w.R)({onFocusWithinChange:t=>{e.setFocused(t)}});return{gridProps:Object.assign(Object.assign({role:"grid","aria-label":"years"===e.mode||"quarters"===e.mode?`${e.startDate.year()} \u2014 ${e.endDate.year()}`:S(e.focusedDate,"days"===e.mode?"MMMM YYYY":"YYYY",e.timeZone),"aria-disabled":e.disabled?"true":void 0,"aria-readonly":e.readOnly?"true":void 0},t),{onKeyDown:t=>{"ArrowRight"===t.key?(t.preventDefault(),e.focusNextCell()):"ArrowLeft"===t.key?(t.preventDefault(),e.focusPreviousCell()):"ArrowDown"===t.key?(t.preventDefault(),e.focusNextRow()):"ArrowUp"===t.key?(t.preventDefault(),e.focusPreviousRow()):"PageDown"===t.key?(t.preventDefault(),e.focusNextPage(t.shiftKey)):"PageUp"===t.key?(t.preventDefault(),e.focusPreviousPage(t.shiftKey)):"End"===t.key?(t.preventDefault(),e.focusSectionEnd()):"Home"===t.key?(t.preventDefault(),e.focusSectionStart()):"Minus"===t.code?(t.preventDefault(),e.zoomOut()):"Equal"===t.code?(t.preventDefault(),e.zoomIn()):"Enter"!==t.key&&" "!==t.key||(t.preventDefault(),e.selectDate(e.focusedDate))}})}}(e);return(0,s.jsxs)("div",Object.assign({className:I("grid")},c,{children:[a&&(0,s.jsx)(M,{className:I("previous-state"),state:t,animation:a}),(0,s.jsx)(M,{className:I("current-state"),state:e,animation:a,onAnimationEnd:()=>{i(Object.assign(Object.assign({},e),{isFocused:!1}))}},"current")]}))}function M({className:e,state:t,animation:i,onAnimationEnd:n}){return(0,s.jsxs)("div",{className:I("content",{animation:i},e),onAnimationEnd:n,role:"presentation",children:["days"===t.mode&&(0,s.jsx)(P,{state:t}),(0,s.jsx)(F,{state:t})]})}function P({state:e}){const t=function(e){const t=[],i=(0,v.KQ)({timeZone:e.timeZone}).startOf("week");for(let s=0;s<7;s++){const e=i.add({days:s});t.push(e)}return t}(e);return(0,s.jsx)("div",{className:I("grid-row"),role:"row",children:t.map((t=>(0,s.jsx)("div",{className:I("weekday",{weekend:e.isWeekend(t)}),role:"columnheader","aria-label":S(t,"dddd",e.timeZone),children:S(t,"dd",e.timeZone)},t.day())))})}function F({state:e}){const t="days"===e.mode?6:4,i="days"===e.mode?7:3+("quarters"===e.mode?1:0),n=function(e){const t=[],i=(0,v.KQ)({input:e.startDate,timeZone:e.timeZone});if("days"===e.mode){const e=i.startOf("week");for(let i=0;i<42;i++)t.push(e.add({days:i}))}else if("quarters"===e.mode)for(let s=0;s<16;s++)t.push(i.add(s,"quarters"));else for(let s=0;s<12;s++)t.push(i.add({[e.mode]:s}));return t}(e);return(0,s.jsx)("div",{className:I("grid-rowgroup",{mode:e.mode}),role:"rowgroup",children:[...new Array(t).keys()].map((t=>(0,s.jsxs)("div",{className:I("grid-row"),role:"row",children:["quarters"===e.mode?(0,s.jsx)("span",{role:"rowheader",className:I("grid-rowgroup-header"),children:S(n[t*i],"YYYY",e.timeZone)}):null,n.slice(t*i,(t+1)*i).map((t=>(0,s.jsx)(U,{date:t,state:e},t.unix())))]},t)))})}function U({date:e,state:t}){const{cellProps:i,buttonProps:n,formattedDate:r,isDisabled:o,isSelected:a,isRangeSelection:c,isSelectionStart:l,isSelectionEnd:h,isOutsideCurrentRange:d,isUnavailable:u,isCurrent:g,isWeekend:p}=y(e,t);return(0,s.jsx)("div",Object.assign({},i,{children:(0,s.jsx)("div",Object.assign({},n,{className:I("button",{disabled:o,selected:a,"range-selection":c,"selection-start":l,"selection-end":h,"out-of-boundary":d,unavailable:u,current:g,weekend:p}),children:r}))}))}var H=i(85736);function B(e){const t=e?e.timeZone():"default",[i,s]=n.useState(t);e&&t!==i&&s(t);return e?t:i}const W={days:!0,months:!0,quarters:!1,years:!0};function V(e,t){if("days"===t)return e.startOf("month");if("months"===t)return e.startOf("year");if("quarters"===t){const t=4*Math.floor(e.year()/4);return e.startOf("year").set("year",t)}const i=12*Math.floor(e.year()/12);return e.startOf("year").set("year",i)}function z(e,t){if("days"===t)return e.endOf("month").startOf("day");if("months"===t)return e.endOf("year").startOf("month");const i=V(e,t);return"quarters"===t?i.add(15,"quarters"):i.add({[t]:11})}function G(e,t,i,s="days"){return!E(e,t,i).isSame(e,s)}const j=n.forwardRef((function(e,t){const i=function(e){var t,i,s;const{disabled:r,readOnly:o,modes:a=W}=e,[c,l]=(0,H.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),h=N.filter((e=>a[e])),d=h[0]||"days",[u,g]=(0,H.P)(e.mode,null!==(i=e.defaultMode)&&void 0!==i?i:d,e.onUpdateMode),p=u&&h.includes(u)?u:d,m=B(e.value||e.defaultValue||e.focusedValue||e.defaultFocusedValue),f=e.timeZone||m,_=n.useMemo((()=>e.minValue?e.minValue.timeZone(f):void 0),[f,e.minValue]),S=n.useMemo((()=>e.maxValue?e.maxValue.timeZone(f):void 0),[f,e.maxValue]),y=n.useMemo((()=>e.focusedValue?E(e.focusedValue.timeZone(f),_,S):e.focusedValue),[e.focusedValue,_,S,f]),w=n.useMemo((()=>{var t;return E((null===(t=e.defaultFocusedValue?e.defaultFocusedValue:c)||void 0===t?void 0:t.timeZone(f))||C({timeZone:f}).startOf(d),_,S)}),[S,_,e.defaultFocusedValue,f,c,d]),[R,L]=(0,H.P)(y,w,(t=>{var i;null===(i=e.onFocusUpdate)||void 0===i||i.call(e,t.timeZone(m))})),T=null!==(s=null===R||void 0===R?void 0:R.timeZone(f))&&void 0!==s?s:E(C({timeZone:f}),_,S);function x(e){L(E(e.startOf(p),_,S))}G(T,_,S)&&L(E(T,_,S));const[k,A]=n.useState(e.autoFocus||!1),I=V(T,p),O=z(T,p);return{disabled:r,readOnly:o,value:c,setValue(e){if(!r&&!o){let t=E(e,_,S);if(this.isCellUnavailable(t))return;c&&(t=b(t,c.timeZone(f))),l(t.timeZone(m))}},timeZone:f,selectDate(e,t=!1){r||(o||!t&&this.mode!==d?this.zoomIn():(this.setValue(e.startOf(d)),t&&p!==d&&g(d)))},minValue:_,maxValue:S,focusedDate:T,startDate:I,endDate:O,setFocusedDate(e){x(e),A(!0)},focusNextCell(){x(T.add(1,this.mode))},focusPreviousCell(){x(T.subtract(1,this.mode))},focusNextRow(){"days"===this.mode?x(T.add(1,"week")):"quarters"===this.mode?x(T.add(1,"years")):x(T.add(3,this.mode))},focusPreviousRow(){"days"===this.mode?x(T.subtract(1,"week")):"quarters"===this.mode?x(T.subtract(1,"years")):x(T.subtract(3,this.mode))},focusNextPage(e){"days"===this.mode?x(T.add({months:e?12:1})):"quarters"===this.mode?x(T.add(4,"years")):x(T.add(12,this.mode))},focusPreviousPage(e){"days"===this.mode?x(T.subtract({months:e?12:1})):"quarters"===this.mode?x(T.subtract(4,"years")):x(T.subtract(12,this.mode))},focusSectionStart(){x(V(T,this.mode))},focusSectionEnd(){x(z(T,this.mode))},zoomIn(){const e=h[h.indexOf(this.mode)-1];e&&this.setMode(e)},zoomOut(){const e=h[h.indexOf(this.mode)+1];e&&this.setMode(e)},selectFocusedDate(){this.selectDate(T,!0)},isFocused:k,setFocused:A,isInvalid(e){return G(e,this.minValue,this.maxValue,this.mode)},isPreviousPageInvalid(){const e=this.startDate.subtract(1,"day");return this.isInvalid(e)},isNextPageInvalid(){const e=this.endDate.endOf(this.mode).add(1,"day");return this.isInvalid(e)},isSelected(e){return Boolean(c&&e.isSame(c.timeZone(f),p)&&!this.isCellDisabled(e))},isCellUnavailable(t){return this.mode===d&&Boolean(e.isDateUnavailable&&e.isDateUnavailable(t))},isCellFocused(e){return this.isFocused&&T&&e.isSame(T,p)},isCellDisabled(e){return this.disabled||this.isInvalid(e)},isWeekend(t){return"days"===this.mode&&("function"===typeof e.isWeekend?e.isWeekend(t):function(e){return[0,6].includes(e.day())}(t))},isCurrent(e){return(0,v.KQ)({timeZone:f}).isSame(e,this.mode)},mode:p,setMode:g,availableModes:h}}(e);return(0,s.jsx)(O,Object.assign({ref:t},e,{state:i}))}));var K=i(27145),Y=i(28333);const q=JSON.parse('{"year_placeholder":"Y","month_placeholder":"M","weekday_placeholder":"E","day_placeholder":"D","hour_placeholder":"h","minute_placeholder":"m","second_placeholder":"s","dayPeriod_placeholder":"aa"}'),$=JSON.parse('{"year_placeholder":"\u0413","month_placeholder":"\u041c","weekday_placeholder":"\u0414\u041d","day_placeholder":"\u0414","hour_placeholder":"\u0447","minute_placeholder":"\u043c","second_placeholder":"\u0441","dayPeriod_placeholder":"(\u0434|\u043f)\u043f"}'),Q=(0,R.N)({en:q,ru:$},`${p.C}date-field`),X={year:!0,month:!0,day:!0,hour:!0,minute:!0,second:!0,dayPeriod:!0,weekday:!0},Z={start:"[",end:"]"},J={YY:"year",YYYY:"year",M:"month",MM:"month",MMM:{sectionType:"month",contentType:"letter"},MMMM:{sectionType:"month",contentType:"letter"},D:"day",DD:"day",Do:"day",d:"weekday",dd:{sectionType:"weekday",contentType:"letter"},ddd:{sectionType:"weekday",contentType:"letter"},dddd:{sectionType:"weekday",contentType:"letter"},A:{sectionType:"dayPeriod",contentType:"letter"},a:{sectionType:"dayPeriod",contentType:"letter"},H:"hour",HH:"hour",h:"hour",hh:"hour",m:"minute",mm:"minute",s:"second",ss:"second",z:{sectionType:"timeZoneName",contentType:"letter"},zzz:{sectionType:"timeZoneName",contentType:"letter"},Z:{sectionType:"timeZoneName",contentType:"letter"},ZZ:{sectionType:"timeZoneName",contentType:"letter"}};function ee(e){return 4===(0,v.KQ)().format(e).length}function te(e,t){const{type:i,format:s}=e;switch(i){case"year":{const e=ee(s);return{minValue:e?1:0,maxValue:e?9999:99}}case"month":return{minValue:0,maxValue:11};case"weekday":return{minValue:0,maxValue:6};case"day":return{minValue:1,maxValue:t?t.daysInMonth():31};case"hour":if(function(e){return"15"!==(0,v.KQ)().set("hour",15).format(e)}(s)){const e=t.hour()>=12;return{minValue:e?12:0,maxValue:e?23:11}}return{minValue:0,maxValue:23};case"minute":case"second":return{minValue:0,maxValue:59}}return{}}function ie(e,t){const i=e.type;switch(i){case"year":return ee(e.format)?t.year():Number(t.format(e.format));case"month":case"hour":case"minute":case"second":return t[i]();case"day":return t.date();case"weekday":return t.day();case"dayPeriod":return t.hour()>=12?12:0}}const se={weekday:"day",day:"date",dayPeriod:"hour"};function ne(e){if("literal"===e||"timeZoneName"===e||"unknown"===e)throw new Error(`${e} section does not have duration unit.`);return e in se?se[e]:e}function re(e,t){switch(e.type){case"year":return Q("year_placeholder").repeat((0,v.KQ)().format(t).length);case"month":return Q("month_placeholder").repeat("letter"===e.contentType?4:2);case"day":return Q("day_placeholder").repeat(2);case"weekday":return Q("weekday_placeholder").repeat("letter"===e.contentType?4:2);case"hour":return Q("hour_placeholder").repeat(2);case"minute":return Q("minute_placeholder").repeat(2);case"second":return Q("second_placeholder").repeat(2);case"dayPeriod":return Q("dayPeriod_placeholder");default:return t}}function oe(e){const t=[],i=(0,v.cS)(e);let s="",n=!1,r=!1;for(let o=0;o1;case"day":return(0,v.KQ)().startOf("month").format(i).length>1;case"weekday":return(0,v.KQ)().startOf("week").format(i).length>1;case"hour":return(0,v.KQ)().set("hour",1).format(i).length>1;case"minute":return(0,v.KQ)().set("minute",1).format(i).length>1;case"second":return(0,v.KQ)().set("second",1).format(i).length>1;default:throw new Error("Invalid section type")}}(i.contentType,i.type,t);e.push(Object.assign(Object.assign({},i),{format:t,placeholder:re(i,t),options:le(i,t),hasLeadingZeros:s}))}function ce(e,t){t&&e.push({type:"literal",contentType:"letter",format:t,placeholder:t,hasLeadingZeros:!1})}function le(e,t){switch(e.type){case"month":{const i="letter"===e.contentType?t:"MMMM";let s=(0,v.KQ)().startOf("year");const n=[];for(let e=0;e<12;e++)n.push(s.format(i).toLocaleUpperCase()),s=s.add(1,"months");return n}case"dayPeriod":{const e=(0,v.KQ)().hour(0),i=e.hour(12);return[e.format(t).toLocaleUpperCase(),i.format(t).toLocaleUpperCase()]}case"weekday":{const i="letter"===e.contentType?t:"dddd";let s=(0,v.KQ)().day(0);const n=[];for(let e=0;e<7;e++)n.push(s.format(i).toLocaleUpperCase()),s=s.add(1,"day");return n}}}function he(e,t,i){let s=1;const n=[];let r=-1;for(let o=0;ot[e]))}function fe(e,t){const i=n.useRef(null),[,s]=n.useState({});function r(t){e.setSelectedSections(t),s({})}function o(){var t,n;e.focusSectionInPosition(null!==(n=null===(t=i.current)||void 0===t?void 0:t.selectionStart)&&void 0!==n?n:0),s({})}n.useLayoutEffect((()=>{const t=i.current;if(!t)return;if(null===e.selectedSectionIndexes)return void(t.scrollLeft&&(t.scrollLeft=0));const s=e.sections[e.selectedSectionIndexes.startIndex],n=e.sections[e.selectedSectionIndexes.endIndex];if(s&&n){const e=s.start,i=n.end;e===t.selectionStart&&i===t.selectionEnd||t.setSelectionRange(e,i)}}));const a=n.useMemo((()=>{if(!e.selectedSectionIndexes)return"text";const t=e.sections[e.selectedSectionIndexes.startIndex];return t&&"letter"!==t.contentType?"tel":"text"}),[e.selectedSectionIndexes,e.sections]);return{inputProps:{value:e.text,view:t.view,size:t.size,disabled:e.disabled,hasClear:!e.readOnly&&!e.isEmpty&&t.hasClear,placeholder:t.placeholder,id:t.id,label:t.label,startContent:t.startContent,endContent:t.endContent,pin:t.pin,autoFocus:t.autoFocus,controlRef:i,autoComplete:"off",type:"text",validationState:e.validationState,errorMessage:t.errorMessage,errorPlacement:t.errorPlacement,onUpdate(t){t||e.clearAll()},onFocus(s){var n;if(null===(n=t.onFocus)||void 0===n||n.call(t,s),null!==e.selectedSectionIndexes)return;const a=s.target,c=!i.current;setTimeout((()=>{a&&a===i.current&&(c?e.focusSectionInPosition(0):a.value.length&&Number(a.selectionEnd)-Number(a.selectionStart)===a.value.length?r("all"):o())}))},onBlur(e){var i;null===(i=t.onBlur)||void 0===i||i.call(t,e),r(-1)},onKeyDown(i){var s;null===(s=t.onKeyDown)||void 0===s||s.call(t,i),"ArrowLeft"===i.key?(i.preventDefault(),e.focusPreviousSection()):"ArrowRight"===i.key?(i.preventDefault(),e.focusNextSection()):"Home"===i.key?(i.preventDefault(),e.decrementToMin()):"End"===i.key?(i.preventDefault(),e.incrementToMax()):"ArrowUp"!==i.key||i.altKey?"ArrowDown"!==i.key||i.altKey?"PageUp"===i.key?(i.preventDefault(),e.incrementPage()):"PageDown"===i.key?(i.preventDefault(),e.decrementPage()):"Backspace"===i.key||"Delete"===i.key?(i.preventDefault(),e.clearSection()):"a"===i.key&&(i.ctrlKey||i.metaKey)&&(i.preventDefault(),r("all")):(i.preventDefault(),e.decrement()):(i.preventDefault(),e.increment())},onKeyUp:t.onKeyUp,controlProps:{"aria-label":t["aria-label"]||void 0,"aria-labelledby":t["aria-labelledby"]||void 0,"aria-describedby":t["aria-describedby"]||void 0,"aria-details":t["aria-details"]||void 0,"aria-disabled":e.disabled||void 0,readOnly:e.readOnly,inputMode:a,onClick(){o()},onMouseUp(e){e.preventDefault()},onBeforeInput(t){t.preventDefault();const i=t.data;void 0!==i&&null!==i&&e.onInput(i)},onPaste(t){if(t.preventDefault(),e.readOnly)return;const i=t.clipboardData.getData("text").replace(/[\u2066\u2067\u2068\u2069]/g,"");if(e.selectedSectionIndexes&&e.selectedSectionIndexes.startIndex===e.selectedSectionIndexes.endIndex){const t=e.sections[e.selectedSectionIndexes.startIndex],s=/^\d+$/.test(i),n=/^[a-zA-Z]+$/.test(i);if(Boolean(t&&("digit"===t.contentType&&s||"letter"===t.contentType&&n)))return void e.onInput(i);if(s||n)return}e.setValueFromString(i)}}}}}const _e={year:5,month:2,weekday:3,day:7,hour:2,minute:15,second:15};function ve(e){var t,i;const[s,r]=(0,H.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),o=B(e.value||e.defaultValue||e.placeholderValue),a=e.timeZone||o,c=e=>{r(e?e.timeZone(o):e)},[l,h]=n.useState((()=>C({placeholderValue:e.placeholderValue,timeZone:a}))),d=e.format||"L",u=function(e){const t=e,[i,s]=n.useState((()=>oe(t))),[r,o]=n.useState(t);return t!==r&&(o(t),s(oe(t))),i}(d),g=n.useMemo((()=>u.filter((e=>X[e.type])).reduce(((e,t)=>Object.assign(Object.assign({},e),{[t.type]:!0})),{})),[u]),p=n.useState((()=>s?Object.assign({},g):{}));let m=p[0];const f=p[1];s&&!me(g,m)&&f(Object.assign({},g)),!s&&Object.keys(g).length>0&&me(g,m)&&Object.keys(m).length===Object.keys(g).length&&(m={},f(m),h(C({placeholderValue:e.placeholderValue,timeZone:a})));const _=s&&s.isValid()&&me(g,m)?s.timeZone(a):l.timeZone(a),E=function(e,t,i){const[s,r]=n.useState((()=>({value:t,sections:e,validSegments:i,editableSections:he(e,t,i)})));e===s.sections&&i===s.validSegments&&t.isSame(s.value)&&t.timeZone()===s.value.timeZone()||r({value:t,sections:e,validSegments:i,editableSections:he(e,t,i)});return s}(u,_,m),[S,y]=n.useState(-1),w=n.useMemo((()=>{if(-1===S)return null;if("all"===S)return{startIndex:0,endIndex:E.editableSections.length-1};if("number"===typeof S)return{startIndex:S,endIndex:S};if("string"===typeof S){const e=E.editableSections.findIndex((e=>e.type===S));return{startIndex:e,endIndex:e}}return S}),[S,E.editableSections]);function R(t){e.disabled||e.readOnly||(me(g,m)?s&&t.isSame(s)||c(t):(s&&c(null),h(t)))}function L(e){m[e]=!0,m.day&&m.month&&m.year&&g.weekday&&(m.weekday=!0),m.hour&&g.dayPeriod&&(m.dayPeriod=!0),f(Object.assign({},m))}const T=e.validationState||(function(e,t,i){return!!e&&(!(!t||!e.isBefore(t))||!(!i||!i.isBefore(e)))}(s,e.minValue,e.maxValue)?"invalid":void 0)||(s&&(null===(i=e.isDateUnavailable)||void 0===i?void 0:i.call(e,s))?"invalid":void 0);return function(e){const{value:t,validationState:i,displayValue:s,editableSections:r,selectedSectionIndexes:o,selectedSections:a,isEmpty:c,flushAllValidSections:l,flushValidSection:h,setSelectedSections:d,setValue:u,setDate:g,adjustSection:p,setSection:m,getSectionValue:f,setSectionValue:_,createPlaceholder:v,setValueFromString:E}=e,b=n.useRef(""),{hasDate:S,hasTime:y}=n.useMemo((()=>{let e=!1,t=!1;for(const i of r)t||(t=["hour","minute","second"].includes(i.type)),e||(e=["day","month","year"].includes(i.type));return{hasTime:t,hasDate:e}}),[r]);return{value:t,isEmpty:c,displayValue:s,setValue:u,setDate:g,text:(w=r,"\u2066"+w.map((e=>e.textValue)).join("")+"\u2069"),readOnly:e.readOnly,disabled:e.disabled,sections:r,hasDate:S,hasTime:y,selectedSectionIndexes:o,validationState:i,setSelectedSections(e){b.current="",d(e)},focusSectionInPosition(e){const t=this.sections.findIndex((t=>t.end>=e)),i=-1===t?0:t,s=this.sections[i];s&&this.setSelectedSections(X[s.type]?i:s.nextEditableSection)},focusNextSection(){var e,t;const i="all"===a?0:a,s=null!==(t=null===(e=this.sections[i])||void 0===e?void 0:e.nextEditableSection)&&void 0!==t?t:-1;-1!==s&&this.setSelectedSections(s)},focusPreviousSection(){var e,t;const i="all"===a?0:a,s=null!==(t=null===(e=this.sections[i])||void 0===e?void 0:e.previousEditableSection)&&void 0!==t?t:-1;-1!==s&&this.setSelectedSections(s)},focusFirstSection(){var e,t;const i=null!==(t=null===(e=this.sections[0])||void 0===e?void 0:e.previousEditableSection)&&void 0!==t?t:-1;-1!==i&&d(i)},focusLastSection(){var e,t;const i=null!==(t=null===(e=this.sections[this.sections.length-1])||void 0===e?void 0:e.nextEditableSection)&&void 0!==t?t:-1;-1!==i&&this.setSelectedSections(i)},increment(){if(this.readOnly||this.disabled)return;b.current="";const e=ge(this.sections,a);-1!==e&&p(e,1)},decrement(){if(this.readOnly||this.disabled)return;b.current="";const e=ge(this.sections,a);-1!==e&&p(e,-1)},incrementPage(){if(this.readOnly||this.disabled)return;b.current="";const e=ge(this.sections,a);-1!==e&&p(e,_e[this.sections[e].type]||1)},decrementPage(){if(this.readOnly||this.disabled)return;b.current="";const e=ge(this.sections,a);-1!==e&&p(e,-(_e[this.sections[e].type]||1))},incrementToMax(){if(this.readOnly||this.disabled)return;b.current="";const e=ge(this.sections,a);if(-1!==e){const t=this.sections[e];"number"===typeof t.maxValue&&m(e,t.maxValue)}},decrementToMin(){if(this.readOnly||this.disabled)return;b.current="";const e=ge(this.sections,a);if(-1!==e){const t=this.sections[e];"number"===typeof t.minValue&&m(e,t.minValue)}},clearSection(){if(this.readOnly||this.disabled)return;if(b.current="","all"===a)return void this.clearAll();const t=ge(this.sections,a);if(-1===t)return;h(t);const i=this.sections[t],s=C({placeholderValue:e.placeholderValue,timeZone:e.timeZone}).timeZone(e.timeZone),n=f(t);let r=n;if("dayPeriod"===i.type){const e=n.hour()>=12,t=s.hour()>=12;e&&!t?r=n.set("hour",n.hour()-12):!e&&t&&(r=n.set("hour",n.hour()+12))}else{const e=ne(i.type);r=n.set(e,s[e]())}_(t,r)},clearAll(){if(this.readOnly||this.disabled)return;b.current="",l(),null!==t&&g(null);const e=v();u(e)},onInput(e){if(this.readOnly||this.disabled)return;const t=ge(this.sections,a);if(-1===t)return;const i=this.sections[t];let s=b.current+e;const n=n=>{var r,o,a;let c="month"===i.type?n-1:n;const l=0===i.minValue;if("hour"!==i.type||12!==i.minValue&&11!==i.maxValue){if(c>(null!==(r=i.maxValue)&&void 0!==r?r:0)&&(c=Number(e)-("month"===i.type?1:0),s=e,c>(null!==(o=i.maxValue)&&void 0!==o?o:0)))return void(b.current="")}else n>12&&(c=Number(e)),12===i.minValue&&c>1&&(c+=12);const h=c>0||0===c&&l;h&&m(t,c),Number(n+"0")>(null!==(a=i.maxValue)&&void 0!==a?a:0)||s.length>=String(i.maxValue).length?(b.current="",h&&this.focusNextSection()):b.current=s},r=n=>{var r;const o=null!==(r=i.options)&&void 0!==r?r:[];let a=n.toLocaleUpperCase(),c=o.filter((e=>e.startsWith(a)));if(0===c.length&&(n!==e&&(a=e.toLocaleUpperCase(),c=o.filter((e=>e.startsWith(a)))),0===c.length))return void(b.current="");const l=c[0],h=o.indexOf(l);"dayPeriod"===i.type?m(t,1===h?12:0):m(t,h),c.length>1?b.current=s:(b.current="",this.focusNextSection())};switch(i.type){case"day":case"hour":case"minute":case"second":case"year":if(!Number.isInteger(Number(s)))return;n(Number(s));break;case"dayPeriod":r(s);break;case"weekday":case"month":Number.isInteger(Number(s))?n(Number(s)):r(s)}},setValueFromString:e=>(b.current="",E(e))};var w}({value:s,displayValue:_,placeholderValue:e.placeholderValue,timeZone:a,validationState:T,editableSections:E.editableSections,readOnly:e.readOnly,disabled:e.disabled,selectedSectionIndexes:w,selectedSections:S,isEmpty:0===Object.keys(m).length,flushAllValidSections:function(){m={},f({})},flushValidSection:function(e){const t=E.editableSections[e];t&&delete m[t.type],f(Object.assign({},m))},setSelectedSections:y,setValue:R,setDate:c,adjustSection:function(e,t){const i=E.editableSections[e];i&&(m[i.type]?R(function(e,t,i){var s;let n=null!==(s=e.value)&&void 0!==s?s:0;if("dayPeriod"===e.type)n=t.hour()+(t.hour()>=12?-12:12);else{n+=i;const t=e.minValue,s=e.maxValue;if("number"===typeof t&&"number"===typeof s){const e=s-t+1;n=(n-t+e)%e+t}}"year"!==e.type||ee(e.format)||(n=(0,v.KQ)({input:`${n}`.padStart(2,"0"),format:e.format}).year());const r=ne(e.type);return t.set(r,n)}(i,_,t)):(L(i.type),Object.keys(m).length>=Object.keys(g).length&&R(_)))},setSection:function(e,t){const i=E.editableSections[e];i&&(L(i.type),R(function(e,t,i){const s=e.type;switch(s){case"year":return t.set("year",ee(e.format)?i:(0,v.KQ)({input:`${i}`.padStart(2,"0"),format:e.format}).year());case"day":case"weekday":case"month":return t.set(ne(s),i);case"dayPeriod":{const e=t.hour(),s=e>=12;return i>=12===s?t:t.set("hour",s?e-12:e+12)}case"hour":{let s=i;if(12===e.minValue||11===e.maxValue){const e=t.hour()>=12;e||12!==s||(s=0),e&&s<12&&(s+=12)}return t.set("hour",s)}case"minute":case"second":return t.set(s,i)}return t}(i,_,t)))},getSectionValue:function(e){return _},setSectionValue:function(e,t){R(t)},createPlaceholder:function(){return C({placeholderValue:e.placeholderValue,timeZone:a}).timeZone(a)},setValueFromString:function(e){const t=function(e,t,i){let s=pe({input:e,format:t,timeZone:i});s.isValid()&&i&&!function(e){return/z$/i.test(e)||/[+-]\d\d:\d\d$/.test(e)}(e)&&(s=b(s,pe({input:e,format:t})));return s}(e,d,a);return!!t.isValid()&&(c(t),!0)}})}const Ce=(0,p.o)("date-field");function Ee(e){var{className:t}=e,i=(0,K.Tt)(e,["className"]);const r=ve(i),{inputProps:o}=fe(r,i),[a,c]=n.useState(!1),{focusWithinProps:l}=(0,w.R)({onFocusWithinChange(e){c(e)}});return(0,s.jsxs)("div",Object.assign({className:Ce(null,t),style:i.style},l,{children:[(0,s.jsx)(h.k,Object.assign({},o,{value:r.isEmpty&&!a&&i.placeholder?"":o.value})),(0,s.jsx)(Y.t,{name:i.name,value:r.value,toStringValue:e=>{var t;return null!==(t=null===e||void 0===e?void 0:e.toISOString())&&void 0!==t?t:""},onReset:e=>{r.setDate(e)},disabled:r.disabled,form:i.form})]}))}const be=(0,p.o)("mobile-calendar");function Se({props:e,state:t}){var i,n;let r="date";return t.hasTime&&t.hasDate?r="datetime-local":t.hasTime&&(r="time"),(0,s.jsx)("input",{className:be(),disabled:e.disabled,type:r,value:we(t.dateFieldState.value,r),id:e.id,min:we(null===(i=e.minValue)||void 0===i?void 0:i.timeZone(t.timeZone),r),max:we(null===(n=e.maxValue)||void 0===n?void 0:n.timeZone(t.timeZone),r),tabIndex:-1,onChange:i=>{var s,n;if(e.readOnly)return;const o=i.target.value;if(o){const i=(0,v.KQ)({input:o,format:ye(r),timeZone:"system"}).timeZone(t.timeZone,!0);let a=t.hasDate?i:C({placeholderValue:null===(s=e.placeholderValue)||void 0===s?void 0:s.timeZone(t.timeZone),timeZone:t.timeZone});a=t.hasTime?b(a,i):t.value?b(a,t.value.timeZone(t.timeZone)):b(a,C({placeholderValue:null===(n=e.placeholderValue)||void 0===n?void 0:n.timeZone(t.timeZone),timeZone:t.timeZone})),t.setValue(a)}else t.setValue(null)}})}function ye(e){switch(e){case"time":return"HH:mm";case"datetime-local":return"YYYY-MM-DDTHH:mm";default:return"YYYY-MM-DD"}}function we(e,t){if(!e)return"";const i=ye(t);return e.format(i)}const Re=(0,p.o)("stub-button");function Le({size:e,icon:t}){return(0,s.jsx)("span",{className:Re({size:e}),children:(0,s.jsx)("span",{className:Re("icon"),children:(0,s.jsx)(u.I,{data:t})})})}var Te=i(43491);function xe(...e){const t=Object.assign({},e[0]);for(let i=1;i=65&&e.charCodeAt(2)<=90?t[e]=ke(i,n):t[e]="className"===e&&"string"===typeof i&&"string"===typeof n?i+" "+n:"controlProps"===e&&"object"===typeof i&&"object"===typeof n?xe(i,n):void 0===n?i:n}}return t}function ke(...e){return(...t)=>{for(const i of e)"function"===typeof i&&i(...t)}}const Ae=JSON.parse('{"Calendar":"Calendar","Formula input mode":"Formula input mode"}'),Ne=JSON.parse('{"Calendar":"\u041a\u0430\u043b\u0435\u043d\u0434\u0430\u0440\u044c","Formula input mode":"\u0420\u0435\u0436\u0438\u043c \u0432\u0432\u043e\u0434\u0430 \u0444\u043e\u0440\u043c\u0443\u043b\u044b"}'),Ie=(0,R.N)({en:Ae,ru:Ne},`${p.C}relative-date-picker`);function Oe(e,t){var{onFocus:i,onBlur:s}=t,r=(0,K.Tt)(t,["onFocus","onBlur"]);const{mode:o,setMode:a,datePickerState:l,relativeDateState:h}=e,[d,u]=n.useState("relative"===o?h.lastCorrectDate:l.dateFieldState.displayValue),[g,p]=n.useState(h.lastCorrectDate);g!==h.lastCorrectDate&&(p(h.lastCorrectDate),u(h.lastCorrectDate));const[m,f]=n.useState(l.dateFieldState.displayValue);l.dateFieldState.displayValue.isSame(m,"day")||(f(l.dateFieldState.displayValue),u(l.dateFieldState.displayValue));const{focusWithinProps:_}=(0,w.R)({onFocusWithin:i,onBlurWithin:s,onFocusWithinChange(t){t||e.setActive(!1)}}),[v,C]=(0,H.P)(void 0,!1,r.onOpenChange);!e.isActive&&v&&C(!1);const E={onFocus:()=>{e.isActive||(e.setActive(!0),C(!0))},errorMessage:r.errorMessage,errorPlacement:r.errorPlacement,controlProps:{onClick:()=>{e.disabled||v||(e.setActive(!0),C(!0))},role:"combobox","aria-expanded":v}},{inputProps:b}=fe(l.dateFieldState,Object.assign(Object.assign({},r),{value:void 0,defaultValue:void 0,onUpdate:void 0})),{inputProps:S}=function(e,t){const[i,s]=n.useState(e.lastCorrectDate),[r,o]=n.useState(e.lastCorrectDate);return i!==e.lastCorrectDate&&(s(e.lastCorrectDate),o(e.lastCorrectDate)),{inputProps:{size:t.size,autoFocus:t.autoFocus,value:e.text,onUpdate:e.setText,disabled:e.disabled,hasClear:t.hasClear,validationState:e.validationState,errorMessage:t.errorMessage,errorPlacement:t.errorPlacement,label:t.label,id:t.id,startContent:t.startContent,endContent:t.endContent,pin:t.pin,view:t.view,placeholder:t.placeholder,onKeyDown:t.onKeyDown,onKeyUp:t.onKeyUp,onBlur:t.onBlur,onFocus:t.onFocus,controlProps:{"aria-label":t["aria-label"]||void 0,"aria-labelledby":t["aria-labelledby"]||void 0,"aria-describedby":t["aria-describedby"]||void 0,"aria-details":t["aria-details"]||void 0,"aria-disabled":e.disabled||void 0,readOnly:e.readOnly}},calendarProps:{size:"s"===t.size?"m":t.size,readOnly:!0,value:e.parsedDate,focusedValue:r,onFocusUpdate:o},timeInputProps:{size:t.size,readOnly:!0,value:e.lastCorrectDate,format:"LTS"}}}(h,Object.assign(Object.assign({},r),{value:void 0,defaultValue:void 0,onUpdate:void 0}));let y=r.validationState;y||(y="relative"===o?h.validationState:l.dateFieldState.validationState);const R=n.useRef(null),L=(0,c.N)(R,"relative"===o?S.controlRef:b.controlRef),T=n.useRef(null);function x(){setTimeout((()=>{var e;null===(e=T.current)||void 0===e||e.focus()}))}function k(){setTimeout((()=>{var e;null===(e=R.current)||void 0===e||e.focus({preventScroll:!0})}))}const A=n.useRef(null);return{groupProps:Object.assign(Object.assign({ref:A,tabIndex:-1,role:"group"},_),{onKeyDown:e=>{!e.altKey||"ArrowDown"!==e.key&&"ArrowUp"!==e.key||(e.preventDefault(),e.stopPropagation(),C(!0),x())}}),fieldProps:xe(E,"relative"===o?S:b,"absolute"===o&&l.dateFieldState.isEmpty&&!e.isActive&&r.placeholder?{value:""}:void 0,{controlRef:L,validationState:y}),modeSwitcherProps:{size:(0,Te.h)(r.size),disabled:e.readOnly||e.disabled,view:"flat-secondary",style:{zIndex:2,marginInlineEnd:2},selected:"relative"===o,extraProps:{"aria-label":Ie("Formula input mode")},onClick:()=>{if(a("relative"===o?"absolute":"relative"),"relative"===o){const e=l.value;e&&u(e)}else h.parsedDate&&u(h.parsedDate);k()}},calendarButtonProps:{size:(0,Te.h)(r.size),disabled:e.disabled,extraProps:{"aria-label":Ie("Calendar"),"aria-haspopup":"dialog","aria-expanded":v},view:"flat-secondary",onClick:()=>{e.setActive(!0),C(!v),v||x()}},popupProps:{open:v,onEscapeKeyDown:()=>{C(!1),k()},onOutsideClick:e=>{var t;e.target&&!(null===(t=A.current)||void 0===t?void 0:t.contains(e.target))&&C(!1)},onTransitionExited:()=>{u("relative"===o?h.lastCorrectDate:l.dateFieldState.displayValue)}},calendarProps:{ref:T,size:"s"===r.size?"m":r.size,readOnly:r.readOnly,value:e.selectedDate,onUpdate:t=>{l.setDateValue(t),e.datePickerState.hasTime||(C(!1),k())},focusedValue:d,onFocusUpdate:u,minValue:r.minValue,maxValue:r.maxValue},timeInputProps:{value:l.timeValue,onUpdate:l.setTimeValue,format:l.timeFormat,readOnly:e.readOnly,disabled:e.disabled,timeZone:r.timeZone,hasClear:r.hasClear,size:r.size}}}const De=function({getPlaceholderTime:e,mergeDateTime:t,setTimezone:i,getDateTime:s,useDateFieldState:r}){return function(o){var a,c;const{disabled:l,readOnly:h}=o,[d,u]=(0,H.P)(o.open,null!==(a=o.defaultOpen)&&void 0!==a&&a,o.onOpenChange),g=u,[p,m]=(0,H.P)(o.value,null!==(c=o.defaultValue)&&void 0!==c?c:null,o.onUpdate),[f,_]=n.useState(null),[v,C]=n.useState(null),E=B(s(o.value)||s(o.defaultValue)||o.placeholderValue),b=o.timeZone||E;let S=f,y=v;const w=o.format||"L",R=(e,s)=>{l||h||(m(i(t(e,s),E)),_(null),C(null))},L=r(Object.assign(Object.assign({},o),{value:p,onUpdate(e){e?R(e,e):m(null)},disabled:l,readOnly:h,validationState:o.validationState,minValue:o.minValue,maxValue:o.maxValue,isDateUnavailable:o.isDateUnavailable,format:w,placeholderValue:o.placeholderValue,timeZone:b})),T=n.useMemo((()=>{if(!L.hasTime)return;const e=[],t=L.sections.find((e=>"hour"===e.type));t&&e.push(t.format);const i=L.sections.find((e=>"minute"===e.type));i&&e.push(i.format);const s=L.sections.find((e=>"second"===e.type));s&&e.push(s.format);const n=L.sections.find((e=>"dayPeriod"===e.type));return e.join(":")+(n?` ${n.format}`:"")}),[L.hasTime,L.sections]);p&&(S=i(p,b),L.hasTime&&(y=i(p,b)));return L.hasTime&&!y&&(y=L.displayValue),{value:p,setValue(e){o.readOnly||o.disabled||m(e?i(e,E):null)},dateValue:S,timeValue:y,setDateValue:e=>{if(l||h)return;const t=!L.hasTime;L.hasTime?y||t?R(e,y||e):_(e):R(e,e),t&&g(!1,"ValueSelected")},setTimeValue:t=>{if(l||h)return;const i=null!==t&&void 0!==t?t:e(o.placeholderValue,b);S?R(S,i):C(i)},disabled:l,readOnly:h,format:w,hasDate:L.hasDate,hasTime:L.hasTime,timeFormat:T,timeZone:b,isOpen:d,setOpen(t,i){!t&&!p&&S&&L.hasTime&&R(S,y||e(o.placeholderValue,o.timeZone)),g(t,i)},dateFieldState:L}}}({getPlaceholderTime:function(e,t){return C({placeholderValue:e,timeZone:t})},mergeDateTime:b,setTimezone:(e,t)=>e.timeZone(t),getDateTime:function(e){if(e)return"start"in e&&"end"in e?e.start:e},useDateFieldState:ve});function Me(e){var t;const[i,s]=(0,H.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),[r,o]=n.useState("relative"===(null===i||void 0===i?void 0:i.type)?"relative":"absolute"),[a,c]=n.useState(i);i!==a&&(c(i),i&&i.type!==r&&o(i.type));const[l,h]=n.useState("absolute"===(null===i||void 0===i?void 0:i.type)?i.value:null);"absolute"===(null===i||void 0===i?void 0:i.type)&&i.value!==l&&h(i.value);const d=De({value:l,onUpdate:e=>{h(e),"absolute"===(null===i||void 0===i?void 0:i.type)&&(null===e||void 0===e?void 0:e.isSame(i.value))||s(e?{type:"absolute",value:e}:null)},format:e.format,placeholderValue:e.placeholderValue,timeZone:e.timeZone,disabled:e.disabled,readOnly:e.readOnly,minValue:e.minValue,maxValue:e.maxValue}),[u,g]=n.useState("relative"===(null===i||void 0===i?void 0:i.type)?i.value:null);"relative"===(null===i||void 0===i?void 0:i.type)&&i.value!==u&&g(i.value);const p=function(e){var t;const[i,s]=(0,H.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),[r,o]=n.useState(null!==i&&void 0!==i?i:"");i&&i!==r&&o(i);const a=n.useMemo((()=>{var t;return i&&null!==(t=(0,v.bQ)(i,{timeZone:e.timeZone,roundUp:e.roundUp}))&&void 0!==t?t:null}),[i,e.timeZone,e.roundUp]),[c,l]=n.useState(a);a&&a!==c&&l(a);const h=e.validationState||r&&!a?"invalid":void 0;return{value:i,setValue(t){e.disabled||e.readOnly||s(t)},text:r,setText:t=>{if(!e.disabled&&!e.readOnly)if(o(t),(0,v.eP)(t)){const e=(0,v.bQ)(t);e&&e.isValid()?s(t):s(null)}else s(null)},parsedDate:a,lastCorrectDate:c,validationState:h,disabled:e.disabled,readOnly:e.readOnly}}({value:u,onUpdate:e=>{g(e),"relative"===(null===i||void 0===i?void 0:i.type)&&e===i.value||s(e?{type:"relative",value:e}:null)},disabled:e.disabled,readOnly:e.readOnly,timeZone:d.timeZone,roundUp:e.roundUp});i||("absolute"===r&&l?h(null):"relative"===r&&u&&g(null));const m="relative"===r?p.parsedDate:d.dateFieldState.displayValue,[f,_]=n.useState(!1);return{value:i,setValue(t){e.readOnly||e.disabled||s(t)},disabled:e.disabled,readOnly:e.readOnly,mode:r,setMode(t){e.readOnly||e.disabled||t===r||(o(t),"relative"===t?(!i&&u||i)&&s(u?{type:"relative",value:u}:null):(!i&&l||i)&&s(l?{type:"absolute",value:l}:null))},datePickerState:d,relativeDateState:p,selectedDate:m,isActive:f,setActive:_}}const Pe=(0,p.o)("relative-date-picker");function Fe(e){var t;const i=Me(e),{groupProps:p,fieldProps:m,modeSwitcherProps:f,calendarButtonProps:_,popupProps:v,calendarProps:C,timeInputProps:E}=Oe(i,e),b=n.useRef(null),S=(0,c.N)(b,p.ref),y=(0,l.I)(),w=i.datePickerState.hasTime&&!i.datePickerState.hasDate;return(0,s.jsxs)("div",Object.assign({},p,{ref:S,className:Pe(null,e.className),children:[y&&"absolute"===i.mode&&(0,s.jsx)(Se,{state:i.datePickerState,props:{id:e.id,disabled:e.disabled,readOnly:e.readOnly,placeholderValue:e.placeholderValue,timeZone:e.timeZone}}),(0,s.jsx)(h.k,Object.assign({},m,{controlProps:Object.assign(Object.assign({},m.controlProps),{disabled:y&&"absolute"===i.mode,className:Pe("input",{mobile:y&&"absolute"===i.mode})}),hasClear:e.hasClear&&!(y&&"absolute"===i.mode),startContent:(0,s.jsx)(d.$,Object.assign({},f,{children:(0,s.jsx)(u.I,{data:r})})),endContent:(0,s.jsxs)(n.Fragment,{children:[!y&&!w&&(0,s.jsx)(d.$,Object.assign({},_,{children:(0,s.jsx)(u.I,{data:o.A})})),!y&&w&&(0,s.jsx)(Le,{size:_.size,icon:a}),y&&"absolute"===i.mode&&(0,s.jsx)(Le,{size:_.size,icon:w?a:o.A})]})})),(0,s.jsx)(Y.t,{name:e.name,value:null===(t=i.value)||void 0===t?void 0:t.type,disabled:i.disabled,form:e.form}),(0,s.jsx)(Y.t,{name:e.name,value:i.value,toStringValue:e=>function(e){if(!e)return"";if("relative"===e.type)return e.value;return e.value.toISOString()}(e),onReset:e=>{i.setValue(e)},disabled:i.disabled,form:e.form}),!y&&!w&&(0,s.jsx)(g.z,Object.assign({},v,{anchorRef:b,children:(0,s.jsxs)("div",{className:Pe("popup-content"),children:["function"===typeof e.children?e.children(C):(0,s.jsx)(j,Object.assign({},C)),i.datePickerState.hasTime&&(0,s.jsx)("div",{className:Pe("time-field-wrapper"),children:(0,s.jsx)(Ee,Object.assign({},E))})]})}))]}))}},97360:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"php",extensions:[".php",".php4",".php5",".phtml",".ctp"],aliases:["PHP","php"],mimetypes:["application/x-php"],loader:()=>i.e(86342).then(i.bind(i,86342))})},97681:(e,t,i)=>{"use strict";i.d(t,{c:()=>h,z:()=>l});var s=i(91508),n=i(32799),r=i(1226),o=i(81782),a=i(83069),c=i(36677);class l{static _createWord(e,t,i,s,n){return{start:s,end:n,wordType:t,nextCharClass:i}}static _createIntlWord(e,t){return{start:e.index,end:e.index+e.segment.length,wordType:1,nextCharClass:t}}static _findPreviousWordOnLine(e,t,i){const s=t.getLineContent(i.lineNumber);return this._doFindPreviousWordOnLine(s,e,i)}static _doFindPreviousWordOnLine(e,t,i){let s=0;const n=t.findPrevIntlWordBeforeOrAtOffset(e,i.column-2);for(let r=i.column-2;r>=0;r--){const i=e.charCodeAt(r),o=t.get(i);if(n&&r===n.index)return this._createIntlWord(n,o);if(0===o){if(2===s)return this._createWord(e,s,o,r+1,this._findEndOfWord(e,t,s,r+1));s=1}else if(2===o){if(1===s)return this._createWord(e,s,o,r+1,this._findEndOfWord(e,t,s,r+1));s=2}else if(1===o&&0!==s)return this._createWord(e,s,o,r+1,this._findEndOfWord(e,t,s,r+1))}return 0!==s?this._createWord(e,s,1,0,this._findEndOfWord(e,t,s,0)):null}static _findEndOfWord(e,t,i,s){const n=t.findNextIntlWordAtOrAfterOffset(e,s),r=e.length;for(let o=s;o=0;r--){const s=e.charCodeAt(r),o=t.get(s);if(n&&r===n.index)return r;if(1===o)return r+1;if(1===i&&2===o)return r+1;if(2===i&&0===o)return r+1}return 0}static moveWordLeft(e,t,i,s,n){let r=i.lineNumber,o=i.column;1===o&&r>1&&(r-=1,o=t.getLineMaxColumn(r));let c=l._findPreviousWordOnLine(e,t,new a.y(r,o));if(0===s)return new a.y(r,c?c.start+1:1);if(1===s)return!n&&c&&2===c.wordType&&c.end-c.start===1&&0===c.nextCharClass&&(c=l._findPreviousWordOnLine(e,t,new a.y(r,c.start+1))),new a.y(r,c?c.start+1:1);if(3===s){for(;c&&2===c.wordType;)c=l._findPreviousWordOnLine(e,t,new a.y(r,c.start+1));return new a.y(r,c?c.start+1:1)}return c&&o<=c.end+1&&(c=l._findPreviousWordOnLine(e,t,new a.y(r,c.start+1))),new a.y(r,c?c.end+1:1)}static _moveWordPartLeft(e,t){const i=t.lineNumber,n=e.getLineMaxColumn(i);if(1===t.column)return i>1?new a.y(i-1,e.getLineMaxColumn(i-1)):t;const r=e.getLineContent(i);for(let o=t.column-1;o>1;o--){const e=r.charCodeAt(o-2),t=r.charCodeAt(o-1);if(95===e&&95!==t)return new a.y(i,o);if(45===e&&45!==t)return new a.y(i,o);if((s.Lv(e)||s.DB(e))&&s.Wv(t))return new a.y(i,o);if(s.Wv(e)&&s.Wv(t)&&o+1=c.start+1&&(c=l._findNextWordOnLine(e,t,new a.y(n,c.end+1))),r=c?c.start+1:t.getLineMaxColumn(n);return new a.y(n,r)}static _moveWordPartRight(e,t){const i=t.lineNumber,n=e.getLineMaxColumn(i);if(t.column===n)return i1?u=1:(d--,u=s.getLineMaxColumn(d)):(g&&u<=g.end+1&&(g=l._findPreviousWordOnLine(i,s,new a.y(d,g.start+1))),g?u=g.end+1:u>1?u=1:(d--,u=s.getLineMaxColumn(d))),new c.Q(d,u,h.lineNumber,h.column)}static deleteInsideWord(e,t,i){if(!i.isEmpty())return i;const s=new a.y(i.positionLineNumber,i.positionColumn),n=this._deleteInsideWordWhitespace(t,s);return n||this._deleteInsideWordDetermineDeleteRange(e,t,s)}static _charAtIsWhitespace(e,t){const i=e.charCodeAt(t);return 32===i||9===i}static _deleteInsideWordWhitespace(e,t){const i=e.getLineContent(t.lineNumber),s=i.length;if(0===s)return null;let n=Math.max(t.column-2,0);if(!this._charAtIsWhitespace(i,n))return null;let r=Math.min(t.column-1,s-1);if(!this._charAtIsWhitespace(i,r))return null;for(;n>0&&this._charAtIsWhitespace(i,n-1);)n--;for(;r+11?new c.Q(i.lineNumber-1,t.getLineMaxColumn(i.lineNumber-1),i.lineNumber,1):i.lineNumbere.start+1<=i.column&&i.column<=e.end+1,o=(e,t)=>(e=Math.min(e,i.column),t=Math.max(t,i.column),new c.Q(i.lineNumber,e,i.lineNumber,t)),a=e=>{let t=e.start+1,i=e.end+1,r=!1;for(;i-11&&this._charAtIsWhitespace(s,t-2);)t--;return o(t,i)},h=l._findPreviousWordOnLine(e,t,i);if(h&&r(h))return a(h);const d=l._findNextWordOnLine(e,t,i);return d&&r(d)?a(d):h&&d?o(h.end+1,d.start+1):h?o(h.start+1,h.end+1):d?o(d.start+1,d.end+1):o(1,n+1)}static _deleteWordPartLeft(e,t){if(!t.isEmpty())return t;const i=t.getPosition(),s=l._moveWordPartLeft(e,i);return new c.Q(i.lineNumber,i.column,s.lineNumber,s.column)}static _findFirstNonWhitespaceChar(e,t){const i=e.length;for(let s=t;s=p.start+1&&(p=l._findNextWordOnLine(i,s,new a.y(h,p.end+1))),p?d=p.start+1:dBoolean(e)))}},97791:()=>{},97884:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"html",extensions:[".html",".htm",".shtml",".xhtml",".mdoc",".jsp",".asp",".aspx",".jshtm"],aliases:["HTML","htm","html","xhtml"],mimetypes:["text/html","text/x-jshtm","text/template","text/ng-template"],loader:()=>i.e(96554).then(i.bind(i,96554))})},98031:(e,t,i)=>{"use strict";i.d(t,{b:()=>s});const s=(0,i(63591).u1)("keybindingService")},98067:(e,t,i)=>{"use strict";i.d(t,{BH:()=>D,Fr:()=>I,H8:()=>W,HZ:()=>k,OS:()=>F,UP:()=>G,_p:()=>P,cm:()=>B,gm:()=>V,ib:()=>x,j9:()=>T,lg:()=>A,m0:()=>j,nr:()=>z,uF:()=>R,un:()=>N,zx:()=>L});var s=i(78209);const n="en";let r,o,a=!1,c=!1,l=!1,h=!1,d=!1,u=!1,g=!1,p=!1,m=!1,f=!1,_=n,v=null,C=null;const E=globalThis;let b;"undefined"!==typeof E.vscode&&"undefined"!==typeof E.vscode.process?b=E.vscode.process:"undefined"!==typeof process&&"string"===typeof process?.versions?.node&&(b=process);const S="string"===typeof b?.versions?.electron,y=S&&"renderer"===b?.type;if("object"===typeof b){a="win32"===b.platform,c="darwin"===b.platform,l="linux"===b.platform,h=l&&!!b.env.SNAP&&!!b.env.SNAP_REVISION,g=S,m=!!b.env.CI||!!b.env.BUILD_ARTIFACTSTAGINGDIRECTORY,r=n,_=n;const e=b.env.VSCODE_NLS_CONFIG;if(e)try{const t=JSON.parse(e);r=t.userLocale,v=t.osLocale,_=t.resolvedLanguage||n,C=t.languagePack?.translationsConfigFile}catch(K){}d=!0}else"object"!==typeof navigator||y?console.error("Unable to resolve platform."):(o=navigator.userAgent,a=o.indexOf("Windows")>=0,c=o.indexOf("Macintosh")>=0,p=(o.indexOf("Macintosh")>=0||o.indexOf("iPad")>=0||o.indexOf("iPhone")>=0)&&!!navigator.maxTouchPoints&&navigator.maxTouchPoints>0,l=o.indexOf("Linux")>=0,f=o?.indexOf("Mobi")>=0,u=!0,_=s.i8()||n,r=navigator.language.toLowerCase(),v=r);let w=0;c?w=1:a?w=3:l&&(w=2);const R=a,L=c,T=l,x=d,k=u,A=u&&"function"===typeof E.importScripts?E.origin:void 0,N=p,I=f,O=o,D=_,M="function"===typeof E.postMessage&&!E.importScripts,P=(()=>{if(M){const e=[];E.addEventListener("message",(t=>{if(t.data&&t.data.vscodeScheduleAsyncWork)for(let i=0,s=e.length;i{const s=++t;e.push({id:s,callback:i}),E.postMessage({vscodeScheduleAsyncWork:s},"*")}}return e=>setTimeout(e)})(),F=c||p?2:a?1:3;let U=!0,H=!1;function B(){if(!H){H=!0;const e=new Uint8Array(2);e[0]=1,e[1]=2;const t=new Uint16Array(e.buffer);U=513===t[0]}return U}const W=!!(O&&O.indexOf("Chrome")>=0),V=!!(O&&O.indexOf("Firefox")>=0),z=!!(!W&&O&&O.indexOf("Safari")>=0),G=!!(O&&O.indexOf("Edg/")>=0),j=!!(O&&O.indexOf("Android")>=0)},98192:(e,t,i)=>{"use strict";i.d(t,{CU:()=>n,om:()=>r});var s=i(82435);const n="gc-",r=((0,s.withNaming)({e:"__",m:"_",v:"_"}),(0,s.withNaming)({n:n,e:"__",m:"_",v:"_"}))},98232:(e,t,i)=>{"use strict";i.r(t),i.d(t,{encodeSemanticTokensDto:()=>r});var s=i(81674),n=i(98067);function r(e){const t=new Uint32Array(function(e){let t=0;if(t+=2,"full"===e.type)t+=1+e.data.length;else{t+=1,t+=3*e.deltas.length;for(const i of e.deltas)i.data&&(t+=i.data.length)}return t}(e));let i=0;if(t[i++]=e.id,"full"===e.type)t[i++]=1,t[i++]=e.data.length,t.set(e.data,i),i+=e.data.length;else{t[i++]=2,t[i++]=e.deltas.length;for(const s of e.deltas)t[i++]=s.start,t[i++]=s.deleteCount,s.data?(t[i++]=s.data.length,t.set(s.data,i),i+=s.data.length):t[i++]=0}return function(e){const t=new Uint8Array(e.buffer,e.byteOffset,4*e.length);return n.cm()||function(e){for(let t=0,i=e.length;t{"use strict";(0,i(34918).K)({id:"wgsl",extensions:[".wgsl"],aliases:["WebGPU Shading Language","WGSL","wgsl"],loader:()=>i.e(33822).then(i.bind(i,33822))})},98472:(e,t,i)=>{"use strict";var s=i(11007),n=i(77163),r=i(78209),o=i(27195);class a extends o.L{static{this.ID="editor.action.toggleTabFocusMode"}constructor(){super({id:a.ID,title:r.aS({key:"toggle.tabMovesFocus",comment:["Turn on/off use of tab key for moving focus around VS Code"]},"Toggle Tab Key Moves Focus"),precondition:void 0,keybinding:{primary:2091,mac:{primary:1323},weight:100},metadata:{description:r.aS("tabMovesFocusDescriptions","Determines whether the tab key moves focus around the workbench or inserts the tab character in the current editor. This is also called tab trapping, tab navigation, or tab focus mode.")},f1:!0})}run(){const e=!n.M.getTabFocusMode();n.M.setTabFocusMode(e),e?(0,s.xE)(r.kg("toggle.tabMovesFocus.on","Pressing Tab will now move focus to the next focusable element")):(0,s.xE)(r.kg("toggle.tabMovesFocus.off","Pressing Tab will now insert the tab character"))}}(0,o.ug)(a)},98745:(e,t,i)=>{"use strict";var s,n=i(5662),r=i(64383),o=i(23750),a=i(84001),c=i(90766),l=i(18447),h=i(47612),d=i(45538),u=i(32371),g=i(32500),p=i(78381),m=i(56942),f=i(74243),_=i(72466),v=i(84585),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},E=function(e,t){return function(i,s){t(i,s,e)}};let b=class extends n.jG{constructor(e,t,i,s,n,r){super(),this._watchers=Object.create(null);const o=t=>{this._watchers[t.uri.toString()]=new S(t,e,i,n,r)},a=(e,t)=>{t.dispose(),delete this._watchers[e.uri.toString()]},c=()=>{for(const e of t.getModels()){const t=this._watchers[e.uri.toString()];(0,v.K)(e,i,s)?t||o(e):t&&a(e,t)}};t.getModels().forEach((e=>{(0,v.K)(e,i,s)&&o(e)})),this._register(t.onModelAdded((e=>{(0,v.K)(e,i,s)&&o(e)}))),this._register(t.onModelRemoved((e=>{const t=this._watchers[e.uri.toString()];t&&a(e,t)}))),this._register(s.onDidChangeConfiguration((e=>{e.affectsConfiguration(v.r)&&c()}))),this._register(i.onDidColorThemeChange(c))}dispose(){for(const e of Object.values(this._watchers))e.dispose();super.dispose()}};b=C([E(0,f.ISemanticTokensStylingService),E(1,o.IModelService),E(2,h.Gy),E(3,a.pG),E(4,g.ILanguageFeatureDebounceService),E(5,m.ILanguageFeaturesService)],b);let S=class extends n.jG{static{s=this}static{this.REQUEST_MIN_DELAY=300}static{this.REQUEST_MAX_DELAY=2e3}constructor(e,t,i,r,o){super(),this._semanticTokensStylingService=t,this._isDisposed=!1,this._model=e,this._provider=o.documentSemanticTokensProvider,this._debounceInformation=r.for(this._provider,"DocumentSemanticTokens",{min:s.REQUEST_MIN_DELAY,max:s.REQUEST_MAX_DELAY}),this._fetchDocumentSemanticTokens=this._register(new c.uC((()=>this._fetchDocumentSemanticTokensNow()),s.REQUEST_MIN_DELAY)),this._currentDocumentResponse=null,this._currentDocumentRequestCancellationTokenSource=null,this._documentProvidersChangeListeners=[],this._providersChangedDuringRequest=!1,this._register(this._model.onDidChangeContent((()=>{this._fetchDocumentSemanticTokens.isScheduled()||this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._register(this._model.onDidChangeAttached((()=>{this._fetchDocumentSemanticTokens.isScheduled()||this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._register(this._model.onDidChangeLanguage((()=>{this._currentDocumentResponse&&(this._currentDocumentResponse.dispose(),this._currentDocumentResponse=null),this._currentDocumentRequestCancellationTokenSource&&(this._currentDocumentRequestCancellationTokenSource.cancel(),this._currentDocumentRequestCancellationTokenSource=null),this._setDocumentSemanticTokens(null,null,null,[]),this._fetchDocumentSemanticTokens.schedule(0)})));const a=()=>{(0,n.AS)(this._documentProvidersChangeListeners),this._documentProvidersChangeListeners=[];for(const t of this._provider.all(e))"function"===typeof t.onDidChange&&this._documentProvidersChangeListeners.push(t.onDidChange((()=>{this._currentDocumentRequestCancellationTokenSource?this._providersChangedDuringRequest=!0:this._fetchDocumentSemanticTokens.schedule(0)})))};a(),this._register(this._provider.onDidChange((()=>{a(),this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._register(i.onDidColorThemeChange((e=>{this._setDocumentSemanticTokens(null,null,null,[]),this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._fetchDocumentSemanticTokens.schedule(0)}dispose(){this._currentDocumentResponse&&(this._currentDocumentResponse.dispose(),this._currentDocumentResponse=null),this._currentDocumentRequestCancellationTokenSource&&(this._currentDocumentRequestCancellationTokenSource.cancel(),this._currentDocumentRequestCancellationTokenSource=null),(0,n.AS)(this._documentProvidersChangeListeners),this._documentProvidersChangeListeners=[],this._setDocumentSemanticTokens(null,null,null,[]),this._isDisposed=!0,super.dispose()}_fetchDocumentSemanticTokensNow(){if(this._currentDocumentRequestCancellationTokenSource)return;if(!(0,u.br)(this._provider,this._model))return void(this._currentDocumentResponse&&this._model.tokenization.setSemanticTokens(null,!1));if(!this._model.isAttachedToEditor())return;const e=new l.Qi,t=this._currentDocumentResponse?this._currentDocumentResponse.provider:null,i=this._currentDocumentResponse&&this._currentDocumentResponse.resultId||null,s=(0,u.aw)(this._provider,this._model,t,i,e.token);this._currentDocumentRequestCancellationTokenSource=e,this._providersChangedDuringRequest=!1;const n=[],o=this._model.onDidChangeContent((e=>{n.push(e)})),a=new p.W(!1);s.then((e=>{if(this._debounceInformation.update(this._model,a.elapsed()),this._currentDocumentRequestCancellationTokenSource=null,o.dispose(),e){const{provider:t,tokens:i}=e,s=this._semanticTokensStylingService.getStyling(t);this._setDocumentSemanticTokens(t,i||null,s,n)}else this._setDocumentSemanticTokens(null,null,null,n)}),(e=>{e&&(r.MB(e)||"string"===typeof e.message&&-1!==e.message.indexOf("busy"))||r.dz(e),this._currentDocumentRequestCancellationTokenSource=null,o.dispose(),(n.length>0||this._providersChangedDuringRequest)&&(this._fetchDocumentSemanticTokens.isScheduled()||this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model)))}))}static _copy(e,t,i,s,n){n=Math.min(n,i.length-s,e.length-t);for(let r=0;r{(n.length>0||this._providersChangedDuringRequest)&&!this._fetchDocumentSemanticTokens.isScheduled()&&this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))};if(this._currentDocumentResponse&&(this._currentDocumentResponse.dispose(),this._currentDocumentResponse=null),this._isDisposed)e&&t&&e.releaseDocumentSemanticTokens(t.resultId);else if(e&&i){if(!t)return this._model.tokenization.setSemanticTokens(null,!0),void o();if((0,u.yS)(t)){if(!r)return void this._model.tokenization.setSemanticTokens(null,!0);if(0===t.edits.length)t={resultId:t.resultId,data:r.data};else{let e=0;for(const i of t.edits)e+=(i.data?i.data.length:0)-i.deleteCount;const n=r.data,o=new Uint32Array(n.length+e);let a=n.length,c=o.length;for(let l=t.edits.length-1;l>=0;l--){const e=t.edits[l];if(e.start>n.length)return i.warnInvalidEditStart(r.resultId,t.resultId,l,e.start,n.length),void this._model.tokenization.setSemanticTokens(null,!0);const h=a-(e.start+e.deleteCount);h>0&&(s._copy(n,a-h,o,c-h,h),c-=h),e.data&&(s._copy(e.data,0,o,c-e.data.length,e.data.length),c-=e.data.length),a=e.start}a>0&&s._copy(n,0,o,0,a),t={resultId:t.resultId,data:o}}}if((0,u.BB)(t)){this._currentDocumentResponse=new y(e,t.resultId,t.data);const s=(0,d.toMultilineTokens2)(t,i,this._model.getLanguageId());if(n.length>0)for(const e of n)for(const t of s)for(const i of e.changes)t.applyEdit(i.range,i.text);this._model.tokenization.setSemanticTokens(s,!0)}else this._model.tokenization.setSemanticTokens(null,!0);o()}else this._model.tokenization.setSemanticTokens(null,!1)}};S=s=C([E(1,f.ISemanticTokensStylingService),E(2,h.Gy),E(3,g.ILanguageFeatureDebounceService),E(4,m.ILanguageFeaturesService)],S);class y{constructor(e,t,i){this.provider=e,this.resultId=t,this.data=i}dispose(){this.provider.releaseDocumentSemanticTokens(this.resultId)}}(0,_.x)(b)},99020:(e,t,i)=>{"use strict";i.d(t,{Su:()=>d,b7:()=>h,fe:()=>u});var s=i(91508),n=i(98067),r=i(81674);let o,a,c;function l(){return o||(o=new TextDecoder("UTF-16LE")),o}function h(){return c||(c=n.cm()?l():(a||(a=new TextDecoder("UTF-16BE")),a)),c}function d(e,t,i){const s=new Uint16Array(e.buffer,t,i);return i>0&&(65279===s[0]||65534===s[0])?function(e,t,i){const s=[];let n=0;for(let o=0;o=this._capacity)return this._flushBuffer(),void(this._completedStrings[this._completedStrings.length]=e);for(let i=0;i{"use strict";i.d(t,{mR:()=>K,bn:()=>j,QS:()=>G});var s=i(11007),n=i(90766),r=i(24939),o=i(631),a=i(79400),c=i(50868),l=i(34326),h=i(31450),d=i(80301),u=i(29163),g=i(83069),p=i(36677),m=i(60002),f=i(62083),_=i(23646),v=i(79614),C=i(41234),E=i(5662),b=i(89403),S=i(78209),y=i(32848),w=i(14718),R=i(63591),L=i(98031),T=i(59261),x=i(58591),k=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},A=function(e,t){return function(i,s){t(i,s,e)}};const N=new y.N1("hasSymbols",!1,(0,S.kg)("hasSymbols","Whether there are symbol locations that can be navigated via keyboard-only.")),I=(0,R.u1)("ISymbolNavigationService");let O=class{constructor(e,t,i,s){this._editorService=t,this._notificationService=i,this._keybindingService=s,this._currentModel=void 0,this._currentIdx=-1,this._ignoreEditorChange=!1,this._ctxHasSymbols=N.bindTo(e)}reset(){this._ctxHasSymbols.reset(),this._currentState?.dispose(),this._currentMessage?.dispose(),this._currentModel=void 0,this._currentIdx=-1}put(e){const t=e.parent.parent;if(t.references.length<=1)return void this.reset();this._currentModel=t,this._currentIdx=t.references.indexOf(e),this._ctxHasSymbols.set(!0),this._showMessage();const i=new D(this._editorService),s=i.onDidChange((e=>{if(this._ignoreEditorChange)return;const i=this._editorService.getActiveCodeEditor();if(!i)return;const s=i.getModel(),n=i.getPosition();if(!s||!n)return;let r=!1,o=!1;for(const a of t.references)if((0,b.n4)(a.uri,s.uri))r=!0,o=o||p.Q.containsPosition(a.range,n);else if(r)break;r&&o||this.reset()}));this._currentState=(0,E.qE)(i,s)}revealNext(e){if(!this._currentModel)return Promise.resolve();this._currentIdx+=1,this._currentIdx%=this._currentModel.references.length;const t=this._currentModel.references[this._currentIdx];return this._showMessage(),this._ignoreEditorChange=!0,this._editorService.openCodeEditor({resource:t.uri,options:{selection:p.Q.collapseToStart(t.range),selectionRevealType:3}},e).finally((()=>{this._ignoreEditorChange=!1}))}_showMessage(){this._currentMessage?.dispose();const e=this._keybindingService.lookupKeybinding("editor.gotoNextSymbolFromResult"),t=e?(0,S.kg)("location.kb","Symbol {0} of {1}, {2} for next",this._currentIdx+1,this._currentModel.references.length,e.getLabel()):(0,S.kg)("location","Symbol {0} of {1}",this._currentIdx+1,this._currentModel.references.length);this._currentMessage=this._notificationService.status(t)}};O=k([A(0,y.fN),A(1,d.T),A(2,x.Ot),A(3,L.b)],O),(0,w.v)(I,O,1),(0,h.E_)(new class extends h.DX{constructor(){super({id:"editor.gotoNextSymbolFromResult",precondition:N,kbOpts:{weight:100,primary:70}})}runEditorCommand(e,t){return e.get(I).revealNext(t)}}),T.f.registerCommandAndKeybindingRule({id:"editor.gotoNextSymbolFromResult.cancel",weight:100,when:N,primary:9,handler(e){e.get(I).reset()}});let D=class{constructor(e){this._listener=new Map,this._disposables=new E.Cm,this._onDidChange=new C.vl,this.onDidChange=this._onDidChange.event,this._disposables.add(e.onCodeEditorRemove(this._onDidRemoveEditor,this)),this._disposables.add(e.onCodeEditorAdd(this._onDidAddEditor,this)),e.listCodeEditors().forEach(this._onDidAddEditor,this)}dispose(){this._disposables.dispose(),this._onDidChange.dispose(),(0,E.AS)(this._listener.values())}_onDidAddEditor(e){this._listener.set(e,(0,E.qE)(e.onDidChangeCursorPosition((t=>this._onDidChange.fire({editor:e}))),e.onDidChangeModelContent((t=>this._onDidChange.fire({editor:e})))))}_onDidRemoveEditor(e){this._listener.get(e)?.dispose(),this._listener.delete(e)}};D=k([A(0,d.T)],D);var M=i(99645),P=i(84226),F=i(27195),U=i(50091),H=i(73823),B=i(80538),W=i(56942),V=i(42522),z=i(28290);F.ZG.appendMenuItem(F.D8.EditorContext,{submenu:F.D8.EditorContextPeek,title:S.kg("peek.submenu","Peek"),group:"navigation",order:100});class G{static is(e){return!(!e||"object"!==typeof e)&&(e instanceof G||!(!g.y.isIPosition(e.position)||!e.model))}constructor(e,t){this.model=e,this.position=t}}class j extends h.qO{static{this._allSymbolNavigationCommands=new Map}static{this._activeAlternativeCommands=new Set}static all(){return j._allSymbolNavigationCommands.values()}static _patchConfig(e){const t={...e,f1:!0};if(t.menu)for(const i of V.f.wrap(t.menu))i.id!==F.D8.EditorContext&&i.id!==F.D8.EditorContextPeek||(i.when=y.M$.and(e.precondition,i.when));return t}constructor(e,t){super(j._patchConfig(t)),this.configuration=e,j._allSymbolNavigationCommands.set(t.id,this)}runEditorCommand(e,t,i,r){if(!t.hasModel())return Promise.resolve(void 0);const o=e.get(x.Ot),a=e.get(d.T),l=e.get(H.N8),h=e.get(I),u=e.get(W.ILanguageFeaturesService),g=e.get(R._Y),p=t.getModel(),m=t.getPosition(),f=G.is(i)?i:new G(p,m),_=new c.gI(t,5),v=(0,n.PK)(this._getLocationModel(u,f.model,f.position,_.token),_.token).then((async e=>{if(!e||_.token.isCancellationRequested)return;let n;if((0,s.xE)(e.ariaMessage),e.referenceAt(p.uri,m)){const e=this._getAlternativeCommand(t);!j._activeAlternativeCommands.has(e)&&j._allSymbolNavigationCommands.has(e)&&(n=j._allSymbolNavigationCommands.get(e))}const o=e.references.length;if(0===o){if(!this.configuration.muteMessage){const e=p.getWordAtPosition(m);M.k.get(t)?.showMessage(this._getNoResultFoundMessage(e),m)}}else{if(1!==o||!n)return this._onResult(a,h,t,e,r);j._activeAlternativeCommands.add(this.desc.id),g.invokeFunction((e=>n.runEditorCommand(e,t,i,r).finally((()=>{j._activeAlternativeCommands.delete(this.desc.id)}))))}}),(e=>{o.error(e)})).finally((()=>{_.dispose()}));return l.showWhile(v,250),v}async _onResult(e,t,i,s,n){const r=this._getGoToPreference(i);if(i instanceof u.t||!(this.configuration.openInPeek||"peek"===r&&s.references.length>1)){const o=s.firstReference(),a=s.references.length>1&&"gotoAndPeek"===r,c=await this._openReference(i,e,o,this.configuration.openToSide,!a);a&&c?this._openInPeek(c,s,n):s.dispose(),"goto"===r&&t.put(o)}else this._openInPeek(i,s,n)}async _openReference(e,t,i,s,n){let r;if((0,f.Iu)(i)&&(r=i.targetSelectionRange),r||(r=i.range),!r)return;const o=await t.openCodeEditor({resource:i.uri,options:{selection:p.Q.collapseToStart(r),selectionRevealType:3,selectionSource:"code.jump"}},e,s);if(o){if(n){const e=o.getModel(),t=o.createDecorationsCollection([{range:r,options:{description:"symbol-navigate-action-highlight",className:"symbolHighlight"}}]);setTimeout((()=>{o.getModel()===e&&t.clear()}),350)}return o}}_openInPeek(e,t,i){const s=_.X.get(e);s&&e.hasModel()?s.toggleWidget(i??e.getSelection(),(0,n.SS)((e=>Promise.resolve(t))),this.configuration.openInPeek):t.dispose()}}class K extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.hE)(e.definitionProvider,t,i,!1,s),S.kg("def.title","Definitions"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("noResultWord","No definition found for '{0}'",e.word):S.kg("generic.noResults","No definition found")}_getAlternativeCommand(e){return e.getOption(58).alternativeDefinitionCommand}_getGoToPreference(e){return e.getOption(58).multipleDefinitions}}(0,F.ug)(class e extends K{static{this.id="editor.action.revealDefinition"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.id,title:{...S.aS("actions.goToDecl.label","Go to Definition"),mnemonicTitle:S.kg({key:"miGotoDefinition",comment:["&& denotes a mnemonic"]},"Go to &&Definition")},precondition:m.R.hasDefinitionProvider,keybinding:[{when:m.R.editorTextFocus,primary:70,weight:100},{when:y.M$.and(m.R.editorTextFocus,z.W0),primary:2118,weight:100}],menu:[{id:F.D8.EditorContext,group:"navigation",order:1.1},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:2}]}),U.w.registerCommandAlias("editor.action.goToDeclaration",e.id)}}),(0,F.ug)(class e extends K{static{this.id="editor.action.revealDefinitionAside"}constructor(){super({openToSide:!0,openInPeek:!1,muteMessage:!1},{id:e.id,title:S.aS("actions.goToDeclToSide.label","Open Definition to the Side"),precondition:y.M$.and(m.R.hasDefinitionProvider,m.R.isInEmbeddedEditor.toNegated()),keybinding:[{when:m.R.editorTextFocus,primary:(0,r.m5)(2089,70),weight:100},{when:y.M$.and(m.R.editorTextFocus,z.W0),primary:(0,r.m5)(2089,2118),weight:100}]}),U.w.registerCommandAlias("editor.action.openDeclarationToTheSide",e.id)}}),(0,F.ug)(class e extends K{static{this.id="editor.action.peekDefinition"}constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:e.id,title:S.aS("actions.previewDecl.label","Peek Definition"),precondition:y.M$.and(m.R.hasDefinitionProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),keybinding:{when:m.R.editorTextFocus,primary:582,linux:{primary:3140},weight:100},menu:{id:F.D8.EditorContextPeek,group:"peek",order:2}}),U.w.registerCommandAlias("editor.action.previewDeclaration",e.id)}});class Y extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.sv)(e.declarationProvider,t,i,!1,s),S.kg("decl.title","Declarations"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("decl.noResultWord","No declaration found for '{0}'",e.word):S.kg("decl.generic.noResults","No declaration found")}_getAlternativeCommand(e){return e.getOption(58).alternativeDeclarationCommand}_getGoToPreference(e){return e.getOption(58).multipleDeclarations}}(0,F.ug)(class e extends Y{static{this.id="editor.action.revealDeclaration"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.id,title:{...S.aS("actions.goToDeclaration.label","Go to Declaration"),mnemonicTitle:S.kg({key:"miGotoDeclaration",comment:["&& denotes a mnemonic"]},"Go to &&Declaration")},precondition:y.M$.and(m.R.hasDeclarationProvider,m.R.isInEmbeddedEditor.toNegated()),menu:[{id:F.D8.EditorContext,group:"navigation",order:1.3},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:3}]})}_getNoResultFoundMessage(e){return e&&e.word?S.kg("decl.noResultWord","No declaration found for '{0}'",e.word):S.kg("decl.generic.noResults","No declaration found")}}),(0,F.ug)(class extends Y{constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:"editor.action.peekDeclaration",title:S.aS("actions.peekDecl.label","Peek Declaration"),precondition:y.M$.and(m.R.hasDeclarationProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),menu:{id:F.D8.EditorContextPeek,group:"peek",order:3}})}});class q extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.f9)(e.typeDefinitionProvider,t,i,!1,s),S.kg("typedef.title","Type Definitions"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("goToTypeDefinition.noResultWord","No type definition found for '{0}'",e.word):S.kg("goToTypeDefinition.generic.noResults","No type definition found")}_getAlternativeCommand(e){return e.getOption(58).alternativeTypeDefinitionCommand}_getGoToPreference(e){return e.getOption(58).multipleTypeDefinitions}}(0,F.ug)(class e extends q{static{this.ID="editor.action.goToTypeDefinition"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.ID,title:{...S.aS("actions.goToTypeDefinition.label","Go to Type Definition"),mnemonicTitle:S.kg({key:"miGotoTypeDefinition",comment:["&& denotes a mnemonic"]},"Go to &&Type Definition")},precondition:m.R.hasTypeDefinitionProvider,keybinding:{when:m.R.editorTextFocus,primary:0,weight:100},menu:[{id:F.D8.EditorContext,group:"navigation",order:1.4},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:3}]})}}),(0,F.ug)(class e extends q{static{this.ID="editor.action.peekTypeDefinition"}constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:e.ID,title:S.aS("actions.peekTypeDefinition.label","Peek Type Definition"),precondition:y.M$.and(m.R.hasTypeDefinitionProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),menu:{id:F.D8.EditorContextPeek,group:"peek",order:4}})}});class $ extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.eS)(e.implementationProvider,t,i,!1,s),S.kg("impl.title","Implementations"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("goToImplementation.noResultWord","No implementation found for '{0}'",e.word):S.kg("goToImplementation.generic.noResults","No implementation found")}_getAlternativeCommand(e){return e.getOption(58).alternativeImplementationCommand}_getGoToPreference(e){return e.getOption(58).multipleImplementations}}(0,F.ug)(class e extends ${static{this.ID="editor.action.goToImplementation"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.ID,title:{...S.aS("actions.goToImplementation.label","Go to Implementations"),mnemonicTitle:S.kg({key:"miGotoImplementation",comment:["&& denotes a mnemonic"]},"Go to &&Implementations")},precondition:m.R.hasImplementationProvider,keybinding:{when:m.R.editorTextFocus,primary:2118,weight:100},menu:[{id:F.D8.EditorContext,group:"navigation",order:1.45},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:4}]})}}),(0,F.ug)(class e extends ${static{this.ID="editor.action.peekImplementation"}constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:e.ID,title:S.aS("actions.peekImplementation.label","Peek Implementations"),precondition:y.M$.and(m.R.hasImplementationProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),keybinding:{when:m.R.editorTextFocus,primary:3142,weight:100},menu:{id:F.D8.EditorContextPeek,group:"peek",order:5}})}});class Q extends j{_getNoResultFoundMessage(e){return e?S.kg("references.no","No references found for '{0}'",e.word):S.kg("references.noGeneric","No references found")}_getAlternativeCommand(e){return e.getOption(58).alternativeReferenceCommand}_getGoToPreference(e){return e.getOption(58).multipleReferences}}(0,F.ug)(class extends Q{constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:"editor.action.goToReferences",title:{...S.aS("goToReferences.label","Go to References"),mnemonicTitle:S.kg({key:"miGotoReference",comment:["&& denotes a mnemonic"]},"Go to &&References")},precondition:y.M$.and(m.R.hasReferenceProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),keybinding:{when:m.R.editorTextFocus,primary:1094,weight:100},menu:[{id:F.D8.EditorContext,group:"navigation",order:1.45},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:5}]})}async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.NN)(e.referenceProvider,t,i,!0,!1,s),S.kg("ref.title","References"))}}),(0,F.ug)(class extends Q{constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:"editor.action.referenceSearch.trigger",title:S.aS("references.action.label","Peek References"),precondition:y.M$.and(m.R.hasReferenceProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),menu:{id:F.D8.EditorContextPeek,group:"peek",order:6}})}async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.NN)(e.referenceProvider,t,i,!1,!1,s),S.kg("ref.title","References"))}});class X extends j{constructor(e,t,i){super(e,{id:"editor.action.goToLocation",title:S.aS("label.generic","Go to Any Symbol"),precondition:y.M$.and(P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated())}),this._references=t,this._gotoMultipleBehaviour=i}async _getLocationModel(e,t,i,s){return new v.y4(this._references,S.kg("generic.title","Locations"))}_getNoResultFoundMessage(e){return e&&S.kg("generic.noResult","No results for '{0}'",e.word)||""}_getGoToPreference(e){return this._gotoMultipleBehaviour??e.getOption(58).multipleReferences}_getAlternativeCommand(){return""}}U.w.registerCommand({id:"editor.action.goToLocations",metadata:{description:"Go to locations from a position in a file",args:[{name:"uri",description:"The text document in which to start",constraint:a.r},{name:"position",description:"The position at which to start",constraint:g.y.isIPosition},{name:"locations",description:"An array of locations.",constraint:Array},{name:"multiple",description:"Define what to do when having multiple results, either `peek`, `gotoAndPeek`, or `goto`"},{name:"noResultsMessage",description:"Human readable message that shows when locations is empty."}]},handler:async(e,t,i,s,n,r,c)=>{(0,o.j)(a.r.isUri(t)),(0,o.j)(g.y.isIPosition(i)),(0,o.j)(Array.isArray(s)),(0,o.j)("undefined"===typeof n||"string"===typeof n),(0,o.j)("undefined"===typeof c||"boolean"===typeof c);const h=e.get(d.T),u=await h.openCodeEditor({resource:t},h.getFocusedCodeEditor());if((0,l.z9)(u))return u.setPosition(i),u.revealPositionInCenterIfOutsideViewport(i,0),u.invokeWithinContext((e=>{const t=new class extends X{_getNoResultFoundMessage(e){return r||super._getNoResultFoundMessage(e)}}({muteMessage:!Boolean(r),openInPeek:Boolean(c),openToSide:!1},s,n);e.get(R._Y).invokeFunction(t.run.bind(t),u)}))}}),U.w.registerCommand({id:"editor.action.peekLocations",metadata:{description:"Peek locations from a position in a file",args:[{name:"uri",description:"The text document in which to start",constraint:a.r},{name:"position",description:"The position at which to start",constraint:g.y.isIPosition},{name:"locations",description:"An array of locations.",constraint:Array},{name:"multiple",description:"Define what to do when having multiple results, either `peek`, `gotoAndPeek`, or `goto`"}]},handler:async(e,t,i,s,n)=>{e.get(U.d).executeCommand("editor.action.goToLocations",t,i,s,n,void 0,!0)}}),U.w.registerCommand({id:"editor.action.findReferences",handler:(e,t,i)=>{(0,o.j)(a.r.isUri(t)),(0,o.j)(g.y.isIPosition(i));const s=e.get(W.ILanguageFeaturesService),r=e.get(d.T);return r.openCodeEditor({resource:t},r.getFocusedCodeEditor()).then((e=>{if(!(0,l.z9)(e)||!e.hasModel())return;const t=_.X.get(e);if(!t)return;const r=(0,n.SS)((t=>(0,B.NN)(s.referenceProvider,e.getModel(),g.y.lift(i),!1,!1,t).then((e=>new v.y4(e,S.kg("ref.title","References")))))),o=new p.Q(i.lineNumber,i.column,i.lineNumber,i.column);return Promise.resolve(t.toggleWidget(o,r,!1))}))}}),U.w.registerCommandAlias("editor.action.showReferences","editor.action.peekLocations")},99645:(e,t,i)=>{"use strict";i.d(t,{k:()=>v});var s,n=i(68214),r=i(11007),o=i(41234),a=i(16980),c=i(5662),l=i(31450),h=i(36677),d=i(20492),u=i(78209),g=i(32848),p=i(49099),m=i(8597),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class{static{s=this}static{this.ID="editor.contrib.messageController"}static{this.MESSAGE_VISIBLE=new g.N1("messageVisible",!1,u.kg("messageVisible","Whether the editor is currently showing an inline message"))}static get(e){return e.getContribution(s.ID)}constructor(e,t,i){this._openerService=i,this._messageWidget=new c.HE,this._messageListeners=new c.Cm,this._mouseOverMessage=!1,this._editor=e,this._visible=s.MESSAGE_VISIBLE.bindTo(t)}dispose(){this._message?.dispose(),this._messageListeners.dispose(),this._messageWidget.dispose(),this._visible.reset()}showMessage(e,t){let i;(0,r.xE)((0,a.VS)(e)?e.value:e),this._visible.set(!0),this._messageWidget.clear(),this._messageListeners.clear(),this._message=(0,a.VS)(e)?(0,n.Gc)(e,{actionHandler:{callback:t=>{this.closeMessage(),(0,d.i)(this._openerService,t,(0,a.VS)(e)?e.isTrusted:void 0)},disposables:this._messageListeners}}):void 0,this._messageWidget.value=new E(this._editor,t,"string"===typeof e?e:this._message.element),this._messageListeners.add(o.Jh.debounce(this._editor.onDidBlurEditorText,((e,t)=>t),0)((()=>{this._mouseOverMessage||this._messageWidget.value&&m.QX(m.bq(),this._messageWidget.value.getDomNode())||this.closeMessage()}))),this._messageListeners.add(this._editor.onDidChangeCursorPosition((()=>this.closeMessage()))),this._messageListeners.add(this._editor.onDidDispose((()=>this.closeMessage()))),this._messageListeners.add(this._editor.onDidChangeModel((()=>this.closeMessage()))),this._messageListeners.add(m.ko(this._messageWidget.value.getDomNode(),m.Bx.MOUSE_ENTER,(()=>this._mouseOverMessage=!0),!0)),this._messageListeners.add(m.ko(this._messageWidget.value.getDomNode(),m.Bx.MOUSE_LEAVE,(()=>this._mouseOverMessage=!1),!0)),this._messageListeners.add(this._editor.onMouseMove((e=>{e.target.position&&(i?i.containsPosition(e.target.position)||this.closeMessage():i=new h.Q(t.lineNumber-3,1,e.target.position.lineNumber+3,1))})))}closeMessage(){this._visible.reset(),this._messageListeners.clear(),this._messageWidget.value&&this._messageListeners.add(E.fadeOut(this._messageWidget.value))}};v=s=f([_(1,g.fN),_(2,p.C)],v);const C=l.DX.bindToContribution(v.get);(0,l.E_)(new C({id:"leaveEditorMessage",precondition:v.MESSAGE_VISIBLE,handler:e=>e.closeMessage(),kbOpts:{weight:130,primary:9}}));class E{static fadeOut(e){const t=()=>{e.dispose(),clearTimeout(i),e.getDomNode().removeEventListener("animationend",t)},i=setTimeout(t,110);return e.getDomNode().addEventListener("animationend",t),e.getDomNode().classList.add("fadeOut"),{dispose:t}}constructor(e,{lineNumber:t,column:i},s){this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this._editor=e,this._editor.revealLinesInCenterIfOutsideViewport(t,t,0),this._position={lineNumber:t,column:i},this._domNode=document.createElement("div"),this._domNode.classList.add("monaco-editor-overlaymessage"),this._domNode.style.marginLeft="-6px";const n=document.createElement("div");n.classList.add("anchor","top"),this._domNode.appendChild(n);const r=document.createElement("div");"string"===typeof s?(r.classList.add("message"),r.textContent=s):(s.classList.add("message"),r.appendChild(s)),this._domNode.appendChild(r);const o=document.createElement("div");o.classList.add("anchor","below"),this._domNode.appendChild(o),this._editor.addContentWidget(this),this._domNode.classList.add("fadeIn")}dispose(){this._editor.removeContentWidget(this)}getId(){return"messageoverlay"}getDomNode(){return this._domNode}getPosition(){return{position:this._position,preference:[1,2],positionAffinity:1}}afterRender(e){this._domNode.classList.toggle("below",2===e)}}(0,l.HW)(v.ID,v,4)},99669:(e,t,i)=>{"use strict";var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,l=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of c(t))l.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u=new class{constructor(e,t,i){this._onDidChange=new d.Emitter,this._languageId=e,this.setDiagnosticsOptions(t),this.setModeConfiguration(i)}get onDidChange(){return this._onDidChange.event}get languageId(){return this._languageId}get modeConfiguration(){return this._modeConfiguration}get diagnosticsOptions(){return this._diagnosticsOptions}setDiagnosticsOptions(e){this._diagnosticsOptions=e||Object.create(null),this._onDidChange.fire(this)}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(this)}}("json",{validate:!0,allowComments:!0,schemas:[],enableSchemaRequest:!1,schemaRequest:"warning",schemaValidation:"warning",comments:"error",trailingCommas:"error"},{documentFormattingEdits:!0,documentRangeFormattingEdits:!0,completionItems:!0,hovers:!0,documentSymbols:!0,tokens:!0,colors:!0,foldingRanges:!0,diagnostics:!0,selectionRanges:!0});function g(){return i.e(66447).then(i.bind(i,66447))}d.languages.json={jsonDefaults:u,getWorker:()=>g().then((e=>e.getWorker()))},d.languages.register({id:"json",extensions:[".json",".bowerrc",".jshintrc",".jscsrc",".eslintrc",".babelrc",".har"],aliases:["JSON","json"],mimetypes:["application/json"]}),d.languages.onLanguage("json",(()=>{g().then((e=>e.setupMode(u)))}))},99822:(e,t,i)=>{"use strict";var s,n,r=i(31450),o=i(78209),a=i(5662),c=i(28712),l=i(63591),h=i(9270),d=i(98031),u=i(41234),g=i(56942),p=i(60002),m=i(32848),f=i(52363),_=i(8597),v=(i(53396),i(10920)),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},E=function(e,t){return function(i,s){t(i,s,e)}};let b=class extends a.jG{static{s=this}static{this.ID="editor.contrib.standaloneColorPickerController"}constructor(e,t,i){super(),this._editor=e,this._instantiationService=i,this._standaloneColorPickerWidget=null,this._standaloneColorPickerVisible=p.R.standaloneColorPickerVisible.bindTo(t),this._standaloneColorPickerFocused=p.R.standaloneColorPickerFocused.bindTo(t)}showOrFocus(){this._editor.hasModel()&&(this._standaloneColorPickerVisible.get()?this._standaloneColorPickerFocused.get()||this._standaloneColorPickerWidget?.focus():this._standaloneColorPickerWidget=this._instantiationService.createInstance(S,this._editor,this._standaloneColorPickerVisible,this._standaloneColorPickerFocused))}hide(){this._standaloneColorPickerFocused.set(!1),this._standaloneColorPickerVisible.set(!1),this._standaloneColorPickerWidget?.hide(),this._editor.focus()}insertColor(){this._standaloneColorPickerWidget?.updateEditor(),this.hide()}static get(e){return e.getContribution(s.ID)}};b=s=C([E(1,m.fN),E(2,l._Y)],b),(0,r.HW)(b.ID,b,1);let S=class extends a.jG{static{n=this}static{this.ID="editor.contrib.standaloneColorPickerWidget"}constructor(e,t,i,s,n,r,o){super(),this._editor=e,this._standaloneColorPickerVisible=t,this._standaloneColorPickerFocused=i,this._keybindingService=n,this._languageFeaturesService=r,this._editorWorkerService=o,this.allowEditorOverflow=!0,this._position=void 0,this._body=document.createElement("div"),this._colorHover=null,this._selectionSetInEditor=!1,this._onResult=this._register(new u.vl),this.onResult=this._onResult.event,this._standaloneColorPickerVisible.set(!0),this._standaloneColorPickerParticipant=s.createInstance(c.WE,this._editor),this._position=this._editor._getViewModel()?.getPrimaryCursorState().modelState.position;const a=this._editor.getSelection(),l=a?{startLineNumber:a.startLineNumber,startColumn:a.startColumn,endLineNumber:a.endLineNumber,endColumn:a.endColumn}:{startLineNumber:0,endLineNumber:0,endColumn:0,startColumn:0},h=this._register(_.w5(this._body));this._register(h.onDidBlur((e=>{this.hide()}))),this._register(h.onDidFocus((e=>{this.focus()}))),this._register(this._editor.onDidChangeCursorPosition((()=>{this._selectionSetInEditor?this._selectionSetInEditor=!1:this.hide()}))),this._register(this._editor.onMouseMove((e=>{const t=e.target.element?.classList;t&&t.contains("colorpicker-color-decoration")&&this.hide()}))),this._register(this.onResult((e=>{this._render(e.value,e.foundInEditor)}))),this._start(l),this._body.style.zIndex="50",this._editor.addContentWidget(this)}updateEditor(){this._colorHover&&this._standaloneColorPickerParticipant.updateEditorModel(this._colorHover)}getId(){return n.ID}getDomNode(){return this._body}getPosition(){if(!this._position)return null;const e=this._editor.getOption(60).above;return{position:this._position,secondaryPosition:this._position,preference:e?[1,2]:[2,1],positionAffinity:2}}hide(){this.dispose(),this._standaloneColorPickerVisible.set(!1),this._standaloneColorPickerFocused.set(!1),this._editor.removeContentWidget(this),this._editor.focus()}focus(){this._standaloneColorPickerFocused.set(!0),this._body.focus()}async _start(e){const t=await this._computeAsync(e);t&&this._onResult.fire(new y(t.result,t.foundInEditor))}async _computeAsync(e){if(!this._editor.hasModel())return null;const t={range:e,color:{red:0,green:0,blue:0,alpha:1}},i=await this._standaloneColorPickerParticipant.createColorHover(t,new f.L(this._editorWorkerService),this._languageFeaturesService.colorProvider);return i?{result:i.colorHover,foundInEditor:i.foundInEditor}:null}_render(e,t){const i=document.createDocumentFragment(),s={fragment:i,statusBar:this._register(new h.L(this._keybindingService)),onContentsChanged:()=>{},hide:()=>this.hide()};this._colorHover=e;const n=this._standaloneColorPickerParticipant.renderHoverParts(s,[e]);if(!n)return;this._register(n.disposables);const r=n.colorPicker;this._body.classList.add("standalone-colorpicker-body"),this._body.style.maxHeight=Math.max(this._editor.getLayoutInfo().height/4,250)+"px",this._body.style.maxWidth=Math.max(.66*this._editor.getLayoutInfo().width,500)+"px",this._body.tabIndex=0,this._body.appendChild(i),r.layout();const o=r.body,a=o.saturationBox.domNode.clientWidth,c=o.domNode.clientWidth-a-22-8,l=r.body.enterButton;l?.onClicked((()=>{this.updateEditor(),this.hide()}));const d=r.header;d.pickedColorNode.style.width=a+8+"px";d.originalColorNode.style.width=c+"px";const u=r.header.closeButton;u?.onClicked((()=>{this.hide()})),t&&(l&&(l.button.textContent="Replace"),this._selectionSetInEditor=!0,this._editor.setSelection(e.range)),this._editor.layoutContentWidget(this)}};S=n=C([E(3,l._Y),E(4,d.b),E(5,g.ILanguageFeaturesService),E(6,v.IEditorWorkerService)],S);class y{constructor(e,t){this.value=e,this.foundInEditor=t}}var w=i(27195);class R extends r.qO{constructor(){super({id:"editor.action.showOrFocusStandaloneColorPicker",title:{...(0,o.aS)("showOrFocusStandaloneColorPicker","Show or Focus Standalone Color Picker"),mnemonicTitle:(0,o.kg)({key:"mishowOrFocusStandaloneColorPicker",comment:["&& denotes a mnemonic"]},"&&Show or Focus Standalone Color Picker")},precondition:void 0,menu:[{id:w.D8.CommandPalette}],metadata:{description:(0,o.aS)("showOrFocusStandaloneColorPickerDescription","Show or focus a standalone color picker which uses the default color provider. It displays hex/rgb/hsl colors.")}})}runEditorCommand(e,t){b.get(t)?.showOrFocus()}}class L extends r.ks{constructor(){super({id:"editor.action.hideColorPicker",label:(0,o.kg)({key:"hideColorPicker",comment:["Action that hides the color picker"]},"Hide the Color Picker"),alias:"Hide the Color Picker",precondition:p.R.standaloneColorPickerVisible.isEqualTo(!0),kbOpts:{primary:9,weight:100},metadata:{description:(0,o.aS)("hideColorPickerDescription","Hide the standalone color picker.")}})}run(e,t){b.get(t)?.hide()}}class T extends r.ks{constructor(){super({id:"editor.action.insertColorWithStandaloneColorPicker",label:(0,o.kg)({key:"insertColorWithStandaloneColorPicker",comment:["Action that inserts color with standalone color picker"]},"Insert Color with Standalone Color Picker"),alias:"Insert Color with Standalone Color Picker",precondition:p.R.standaloneColorPickerFocused.isEqualTo(!0),kbOpts:{primary:3,weight:100},metadata:{description:(0,o.aS)("insertColorWithStandaloneColorPickerDescription","Insert hex/rgb/hsl colors with the focused standalone color picker.")}})}run(e,t){b.get(t)?.insertColor()}}(0,r.Fl)(L),(0,r.Fl)(T),(0,w.ug)(R)},99908:(e,t,i)=>{"use strict";i.r(t),i.d(t,{clearPlatformLanguageAssociations:()=>p,getLanguageIds:()=>m,registerPlatformLanguageAssociation:()=>g});var s=i(46958),n=i(44320),r=i(36456),o=i(74027),a=i(89403),c=i(91508),l=i(83941);let h=[],d=[],u=[];function g(e,t=!1){!function(e,t,i){const n=function(e,t){return{id:e.id,mime:e.mime,filename:e.filename,extension:e.extension,filepattern:e.filepattern,firstline:e.firstline,userConfigured:t,filenameLowercase:e.filename?e.filename.toLowerCase():void 0,extensionLowercase:e.extension?e.extension.toLowerCase():void 0,filepatternLowercase:e.filepattern?(0,s.qg)(e.filepattern.toLowerCase()):void 0,filepatternOnPath:!!e.filepattern&&e.filepattern.indexOf(o.SA.sep)>=0}}(e,t);h.push(n),n.userConfigured?u.push(n):d.push(n);i&&!n.userConfigured&&h.forEach((e=>{e.mime===n.mime||e.userConfigured||(n.extension&&e.extension===n.extension&&console.warn(`Overwriting extension <<${n.extension}>> to now point to mime <<${n.mime}>>`),n.filename&&e.filename===n.filename&&console.warn(`Overwriting filename <<${n.filename}>> to now point to mime <<${n.mime}>>`),n.filepattern&&e.filepattern===n.filepattern&&console.warn(`Overwriting filepattern <<${n.filepattern}>> to now point to mime <<${n.mime}>>`),n.firstline&&e.firstline===n.firstline&&console.warn(`Overwriting firstline <<${n.firstline}>> to now point to mime <<${n.mime}>>`))}))}(e,!1,t)}function p(){h=h.filter((e=>e.userConfigured)),d=[]}function m(e,t){return function(e,t){let i;if(e)switch(e.scheme){case r.ny.file:i=e.fsPath;break;case r.ny.data:i=a.B6.parseMetaData(e).get(a.B6.META_DATA_LABEL);break;case r.ny.vscodeNotebookCell:i=void 0;break;default:i=e.path}if(!i)return[{id:"unknown",mime:n.K.unknown}];i=i.toLowerCase();const s=(0,o.P8)(i),g=f(i,s,u);if(g)return[g,{id:l.vH,mime:n.K.text}];const p=f(i,s,d);if(p)return[p,{id:l.vH,mime:n.K.text}];if(t){const e=function(e){(0,c.LU)(e)&&(e=e.substr(1));if(e.length>0)for(let t=h.length-1;t>=0;t--){const i=h[t];if(!i.firstline)continue;const s=e.match(i.firstline);if(s&&s.length>0)return i}return}(t);if(e)return[e,{id:l.vH,mime:n.K.text}]}return[{id:"unknown",mime:n.K.unknown}]}(e,t).map((e=>e.id))}function f(e,t,i){let s,n,r;for(let o=i.length-1;o>=0;o--){const a=i[o];if(t===a.filenameLowercase){s=a;break}if(a.filepattern&&(!n||a.filepattern.length>n.filepattern.length)){const i=a.filepatternOnPath?e:t;a.filepatternLowercase?.(i)&&(n=a)}a.extension&&(!r||a.extension.length>r.extension.length)&&t.endsWith(a.extensionLowercase)&&(r=a)}return s||(n||(r||void 0))}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/35566.c06fabb8.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/35566.c06fabb8.chunk.js.LICENSE.txt new file mode 100644 index 000000000000..13f1dfd6411c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35566.c06fabb8.chunk.js.LICENSE.txt @@ -0,0 +1,12 @@ +/*! @license DOMPurify 3.1.7 | (c) Cure53 and other contributors | Released under the Apache license 2.0 and Mozilla Public License 2.0 | github.com/cure53/DOMPurify/blob/3.1.7/LICENSE */ + +/*! Fabric.js Copyright 2008-2015, Printio (Juriy Zaytsev, Maxim Chernyak) */ + +/*! crc32.js (C) 2014-present SheetJS -- http://sheetjs.com */ + +/*!----------------------------------------------------------------------------- + * Copyright (c) Microsoft Corporation. All rights reserved. + * Version: 0.52.2(404545bded1df6ffa41ea0af4e8ddb219018c6c1) + * Released under the MIT license + * https://github.com/microsoft/monaco-editor/blob/main/LICENSE.txt + *-----------------------------------------------------------------------------*/ diff --git a/ydb/core/viewer/monitoring/static/js/35569.8ceadf10.chunk.js b/ydb/core/viewer/monitoring/static/js/35569.8ceadf10.chunk.js new file mode 100644 index 000000000000..dc5a8ed2eabf --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35569.8ceadf10.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[35569],{35569:(n,e,a)=>{a.d(e,{default:()=>i});var t=a(98270);const i=a.n(t)()},98270:n=>{function e(n){n.languages.gap={shell:{pattern:/^gap>[\s\S]*?(?=^gap>|$(?![\s\S]))/m,greedy:!0,inside:{gap:{pattern:/^(gap>).+(?:(?:\r(?:\n|(?!\n))|\n)>.*)*/,lookbehind:!0,inside:null},punctuation:/^gap>/}},comment:{pattern:/#.*/,greedy:!0},string:{pattern:/(^|[^\\'"])(?:'(?:[^\r\n\\']|\\.){1,10}'|"(?:[^\r\n\\"]|\\.)*"(?!")|"""[\s\S]*?""")/,lookbehind:!0,greedy:!0,inside:{continuation:{pattern:/([\r\n])>/,lookbehind:!0,alias:"punctuation"}}},keyword:/\b(?:Assert|Info|IsBound|QUIT|TryNextMethod|Unbind|and|atomic|break|continue|do|elif|else|end|fi|for|function|if|in|local|mod|not|od|or|quit|readonly|readwrite|rec|repeat|return|then|until|while)\b/,boolean:/\b(?:false|true)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:{pattern:/(^|[^\w.]|\.\.)(?:\d+(?:\.\d*)?|\.\d+)(?:[eE][+-]?\d+)?(?:_[a-z]?)?(?=$|[^\w.]|\.\.)/,lookbehind:!0},continuation:{pattern:/([\r\n])>/,lookbehind:!0,alias:"punctuation"},operator:/->|[-+*/^~=!]|<>|[<>]=?|:=|\.\./,punctuation:/[()[\]{},;.:]/},n.languages.gap.shell.inside.gap.inside=n.languages.gap}n.exports=e,e.displayName="gap",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/35596.d9a26c66.chunk.js b/ydb/core/viewer/monitoring/static/js/35596.d9a26c66.chunk.js new file mode 100644 index 000000000000..0ab6698f3d6a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35596.d9a26c66.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[35596],{35596:(e,a,n)=>{n.d(a,{default:()=>o});var t=n(48133);const o=n.n(t)()},48133:e=>{function a(e){e.languages.yang={comment:/\/\*[\s\S]*?\*\/|\/\/.*/,string:{pattern:/"(?:[^\\"]|\\.)*"|'[^']*'/,greedy:!0},keyword:{pattern:/(^|[{};\r\n][ \t]*)[a-z_][\w.-]*/i,lookbehind:!0},namespace:{pattern:/(\s)[a-z_][\w.-]*(?=:)/i,lookbehind:!0},boolean:/\b(?:false|true)\b/,operator:/\+/,punctuation:/[{};:]/}}e.exports=a,a.displayName="yang",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/35614.ff4ff2f4.chunk.js b/ydb/core/viewer/monitoring/static/js/35614.ff4ff2f4.chunk.js new file mode 100644 index 000000000000..08461fb5ba54 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35614.ff4ff2f4.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[35614],{3685:(e,a,s)=>{s.d(a,{$:()=>u});var l=s(54090),t=s(77506),r=s(33775),n=s(60712);const o=(0,t.cn)("ydb-entity-page-title");function u({entityName:e,status:a=l.m.Grey,id:s,className:t}){return(0,n.jsxs)("div",{className:o(null,t),children:[(0,n.jsx)("span",{className:o("prefix"),children:e}),(0,n.jsx)(r.k,{className:o("icon"),status:a,size:"s"}),s]})}},42655:(e,a,s)=>{s.d(a,{y:()=>c});var l=s(59284),t=s(89169),r=s(77506),n=s(66781),o=s(60712);const u=(0,r.cn)("ydb-info-viewer-skeleton"),i=()=>(0,o.jsxs)("div",{className:u("label"),children:[(0,o.jsx)(t.E,{className:u("label__text")}),(0,o.jsx)("div",{className:u("label__dots")})]}),c=({rows:e=8,className:a,delay:s=600})=>{const[r]=(0,n.y)(s);let c=(0,o.jsxs)(l.Fragment,{children:[(0,o.jsx)(i,{}),(0,o.jsx)(t.E,{className:u("value")})]});return r||(c=null),(0,o.jsx)("div",{className:u(null,a),children:[...new Array(e)].map(((e,a)=>(0,o.jsx)("div",{className:u("row"),children:c},`skeleton-row-${a}`)))})}},58389:(e,a,s)=>{s.d(a,{B:()=>d});var l=s(87184),t=s(77506),r=s(90053),n=s(70043),o=s(60712);const u=(0,t.cn)("ydb-page-meta"),i="\xa0\xa0\xb7\xa0\xa0";function c({items:e,loading:a}){return(0,o.jsx)("div",{className:u("info"),children:a?(0,o.jsx)(n.E,{className:u("skeleton")}):e.filter((e=>Boolean(e))).join(i)})}function d({className:e,...a}){return(0,o.jsxs)(l.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:u(null,e),children:[(0,o.jsx)(c,{...a}),(0,o.jsx)(r.E,{})]})}},70043:(e,a,s)=>{s.d(a,{E:()=>n});var l=s(89169),t=s(66781),r=s(60712);const n=({delay:e=600,className:a})=>{const[s]=(0,t.y)(e);return s?(0,r.jsx)(l.E,{className:a}):null}},75510:(e,a,s)=>{s.r(a),s.d(a,{StorageGroupPage:()=>_});var l=s(59284),t=s(44992),r=s(61750),n=s(80987),o=s(3685),u=s(44508),i=s(42655),c=s(58389),d=s(87184),p=s(7435),g=s(56839),v=s(73891),m=s(41650),h=s(60073),f=s(15132),b=s(33775),y=s(48372);const x=JSON.parse('{"encryption":"Encryption","overall":"Overall","disk-space":"Disk Space","media-type":"Media Type","erasure-species":"Erasure Species","used-space":"Used Space","usage":"Usage","read-throughput":"Read Throughput","write-throughput":"Write Throughput","yes":"Yes","no":"No","group-generation":"Group Generation","latency":"Latency","allocation-units":"Units","state":"State","missing-disks":"Missing Disks","available":"Available Space","latency-put-tablet-log":"Latency (Put Tablet Log)","latency-put-user-data":"Latency (Put User Data)","latency-get-fast":"Latency (Get Fast)"}'),N=(0,y.g4)("storage-group-info",{en:x});var j=s(60712);function w({data:e,className:a,...s}){const{Encryption:l,Overall:t,DiskSpace:r,MediaType:n,ErasureSpecies:o,Used:u,Limit:i,Usage:c,Read:y,Write:x,GroupGeneration:w,Latency:k,AllocationUnits:S,State:G,MissingDisks:E,Available:L,LatencyPutTabletLogMs:P,LatencyPutUserDataMs:T,LatencyGetFastMs:A}=e||{},M=[];(0,p.f8)(w)&&M.push({label:N("group-generation"),value:w}),(0,p.f8)(o)&&M.push({label:N("erasure-species"),value:o}),(0,p.f8)(n)&&M.push({label:N("media-type"),value:n}),(0,p.f8)(l)&&M.push({label:N("encryption"),value:N(l?"yes":"no")}),(0,p.f8)(t)&&M.push({label:N("overall"),value:(0,j.jsx)(b.k,{status:t})}),(0,p.f8)(G)&&M.push({label:N("state"),value:G}),(0,p.f8)(E)&&M.push({label:N("missing-disks"),value:E});const $=[];return(0,p.f8)(u)&&(0,p.f8)(i)&&$.push({label:N("used-space"),value:(0,j.jsx)(f.O,{value:Number(u),capacity:Number(i),formatValues:g.vX,colorizeProgress:!0})}),(0,p.f8)(L)&&$.push({label:N("available"),value:(0,g.vX)(Number(L))}),(0,p.f8)(c)&&$.push({label:N("usage"),value:`${c.toFixed(2)}%`}),(0,p.f8)(r)&&$.push({label:N("disk-space"),value:(0,j.jsx)(b.k,{status:r})}),(0,p.f8)(k)&&$.push({label:N("latency"),value:(0,j.jsx)(b.k,{status:k})}),(0,p.f8)(P)&&$.push({label:N("latency-put-tablet-log"),value:(0,v.Xo)(P)}),(0,p.f8)(T)&&$.push({label:N("latency-put-user-data"),value:(0,v.Xo)(T)}),(0,p.f8)(A)&&$.push({label:N("latency-get-fast"),value:(0,v.Xo)(A)}),(0,p.f8)(S)&&$.push({label:N("allocation-units"),value:S}),(0,p.f8)(y)&&$.push({label:N("read-throughput"),value:(0,m.O4)(Number(y))}),(0,p.f8)(x)&&$.push({label:N("write-throughput"),value:(0,m.O4)(Number(x))}),(0,j.jsxs)(d.s,{className:a,gap:2,direction:"row",wrap:!0,children:[(0,j.jsx)(h.z_,{info:M,...s}),(0,j.jsx)(h.z_,{info:$,...s})]})}var k=s(67028),S=s(40174),G=s(10174),E=s(54090),L=s(77506),P=s(90182),T=s(47199);const A=JSON.parse('{"storage-group":"Storage Group","storage":"Storage","pool-name":"Pool Name"}'),M=(0,y.g4)("ydb-storage-group-page",{en:A}),$=(0,L.cn)("ydb-storage-group-page");function _(){var e,a;const s=(0,P.YQ)(),d=l.useRef(null),[{groupId:g}]=(0,n.useQueryParams)({groupId:n.StringParam});l.useEffect((()=>{s((0,S.g)("storageGroup",{groupId:g}))}),[s,g]);const[v]=(0,P.Nt)(),m=(0,k.YA)(),h=(0,k.Pm)(),f=G.S.useGetStorageGroupsInfoQuery((0,p.f8)(g)?{groupId:g,shouldUseGroupsHandler:m,with:"all",fieldsRequired:"all"}:t.hT,{pollingInterval:v,skip:!h}),b=null===(e=f.data)||void 0===e||null===(a=e.groups)||void 0===a?void 0:a[0],y=f.isFetching&&void 0===b;return(0,j.jsxs)("div",{className:$(null),ref:d,children:[(()=>{const e=g?`${M("storage-group")} ${g}`:M("storage-group");return(0,j.jsx)(r.mg,{titleTemplate:`%s - ${e} \u2014 YDB Monitoring`,defaultTitle:`${e} \u2014 YDB Monitoring`})})(),(()=>{if(!g)return null;const e=[`${M("pool-name")}: ${null===b||void 0===b?void 0:b.PoolName}`];return(0,j.jsx)(c.B,{className:$("meta"),loading:y,items:e})})(),(0,j.jsx)(o.$,{className:$("title"),entityName:M("storage-group"),status:(null===b||void 0===b?void 0:b.Overall)||E.m.Grey,id:g}),f.error?(0,j.jsx)(u.o,{error:f.error}):null,y?(0,j.jsx)(i.y,{className:$("info"),rows:10}):(0,j.jsx)(w,{data:b,className:$("info")}),g?(0,j.jsxs)(l.Fragment,{children:[(0,j.jsx)("div",{className:$("storage-title"),children:M("storage")}),(0,j.jsx)(T.z,{groupId:g,scrollContainerRef:d,viewContext:{groupId:null===g||void 0===g?void 0:g.toString()}})]}):null]})}},79879:(e,a,s)=>{s.d(a,{A:()=>t});var l=s(59284);const t=e=>l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),l.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"m3.003 4.702 4.22-2.025a1.8 1.8 0 0 1 1.554 0l4.22 2.025a.89.89 0 0 1 .503.8V6a8.55 8.55 0 0 1-3.941 7.201l-.986.631a1.06 1.06 0 0 1-1.146 0l-.986-.63A8.55 8.55 0 0 1 2.5 6v-.498c0-.341.196-.652.503-.8m3.57-3.377L2.354 3.35A2.39 2.39 0 0 0 1 5.502V6a10.05 10.05 0 0 0 4.632 8.465l.986.63a2.56 2.56 0 0 0 2.764 0l.986-.63A10.05 10.05 0 0 0 15 6v-.498c0-.918-.526-1.755-1.354-2.152l-4.22-2.025a3.3 3.3 0 0 0-2.852 0M9.5 7a1.5 1.5 0 0 1-.75 1.3v1.95a.75.75 0 0 1-1.5 0V8.3A1.5 1.5 0 1 1 9.5 7",clipRule:"evenodd"}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/35742.3e9f175a.chunk.js b/ydb/core/viewer/monitoring/static/js/35742.3e9f175a.chunk.js new file mode 100644 index 000000000000..5fd90cfb3a1f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35742.3e9f175a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[35742],{7701:(e,t,s)=>{s.r(t),s.d(t,{Cluster:()=>ds});var n=s(59284),r=s(89169),l=s(23871),a=s(61750),o=s(10755),i=s(80987),c=s(90053),d=s(60865),u=s(47665),m=s(87184),h=s(98934),v=s(54090),g=s(77506),p=s(43937),x=s(36388),j=s(94420),f=s(70825),N=s(49917),y=s(99991),b=s(60712);const w={[v.m.Blue]:p.A,[v.m.Yellow]:x.A,[v.m.Orange]:j.A,[v.m.Red]:x.A,[v.m.Green]:f.A,[v.m.Grey]:N.A};function _({status:e,...t}){return e?(0,b.jsx)(y.I,{...t,data:w[e]}):null}var C=s(48372);const k=JSON.parse('{"title_red":"Critical","title_blue":"Normal","title_green":"Good","title_grey":"Unknown","title_orange":"Caution","title_yellow":"Warning","context_red":"Some systems are failed and not available","context_yellow":"There are minor issues","context_orange":"Critical state, requires immediate attention","context_green":"Everything is working as expected","context_grey":"The condition cannot be determined","context_blue":"All good, some parts of the system are restoring"}'),S=(0,C.g4)("ydb-entity-status",{en:k}),E={get[v.m.Red](){return S("context_red")},get[v.m.Yellow](){return S("context_yellow")},get[v.m.Orange](){return S("context_orange")},get[v.m.Green](){return S("context_green")},get[v.m.Grey](){return S("context_grey")},get[v.m.Blue](){return S("context_blue")}},T=(0,g.cn)("ydb-entity-status-new"),V={[v.m.Red]:"danger",[v.m.Blue]:"info",[v.m.Green]:"success",[v.m.Grey]:"unknown",[v.m.Orange]:"orange",[v.m.Yellow]:"warning"},O={get[v.m.Red](){return S("title_red")},get[v.m.Yellow](){return S("title_yellow")},get[v.m.Orange](){return S("title_orange")},get[v.m.Green](){return S("title_green")},get[v.m.Grey](){return S("title_grey")},get[v.m.Blue](){return S("title_blue")}};function D({className:e,children:t}){return(0,b.jsx)(m.s,{gap:"2",wrap:"nowrap",alignItems:"center",className:T(null,e),children:t})}D.Label=function({children:e,status:t,withStatusName:s=!0,note:n,size:r="m",iconSize:l=14}){const a=V[t];return(0,b.jsx)(d.m,{title:E[t],disabled:Boolean(n),children:(0,b.jsx)(u.J,{theme:"orange"===a?void 0:a,icon:(0,b.jsx)(_,{size:l,status:t}),size:r,className:T({orange:"orange"===a}),children:(0,b.jsxs)(m.s,{gap:"2",wrap:"nowrap",children:[e,s?O[t]:null,n&&(0,b.jsx)(h.H,{children:n})]})})})},D.displayName="EntityStatus";var A=s(44294),L=s(92459),G=s(67028),z=s(67157),I=s(40174),M=s(90182),R=s(11363),B=s(47199),$=s(88616),P=s(93381),U=s(65872),W=s(64470),F=s(4557),J=s(84476),H=s(40569),Y=s(28539),q=s(44508),Z=s(78524),Q=s(48295),K=s(9252),X=s(17594),ee=s(95963),te=s(69326),se=s(23900),ne=s(54309),re=s(12888),le=s(10508),ae=s(25196);const oe=JSON.parse('{"field_links":"Links","field_monitoring-link":"Monitoring","field_logs-link":"Logs","context_unknown":"unknown database"}'),ie=(0,C.g4)("ydb-tenant-name-wrapper",{en:oe});function ce({tenant:e,additionalTenantsProps:t}){var s,n;const r=(0,re.X)(),l=((e,t)=>{var s;if("function"!==typeof(null===t||void 0===t?void 0:t.prepareTenantBackend))return;let n;const r=null!==(s=e.NodeIds)&&void 0!==s?s:e.sharedNodeIds;r&&r.length>0&&(n=r[Math.floor(Math.random()*r.length)].toString());return t.prepareTenantBackend(n)})(e,t),a=Boolean(l),o=null===t||void 0===t||null===(s=t.getMonitoringLink)||void 0===s?void 0:s.call(t,e.Name,e.Type),i=null===t||void 0===t||null===(n=t.getLogsLink)||void 0===n?void 0:n.call(t,e.Name),c=(o||i)&&r?(0,b.jsx)(se.u,{responsive:!0,children:(0,b.jsx)(se.u.Item,{name:ie("field_links"),children:(0,b.jsxs)(m.s,{gap:2,wrap:"wrap",children:[o&&(0,b.jsx)(ae.K,{title:ie("field_monitoring-link"),url:o}),i&&(0,b.jsx)(ae.K,{title:ie("field_logs-link"),url:i})]})})}):null;return(0,b.jsx)(le.c,{externalLink:a,name:e.Name||ie("context_unknown"),withLeftTrim:!0,status:e.Overall,infoPopoverContent:c,hasClipboardButton:!0,path:(0,ne.YL)({database:e.Name,backend:l},{withBasename:a})})}var de=s(88610),ue=s(53850),me=s(23536),he=s.n(me),ve=s(76086),ge=s(56674);const pe=(0,ue.Mz)((e=>e),(e=>ge.GJ.endpoints.getTenantsInfo.select({clusterName:e}))),xe=(0,ue.Mz)((e=>e),((e,t)=>pe(t)),(e=>(0,de.CN)(e,ve.Xm)),((e,t,s)=>{var n;const r=null!==(n=t(e).data)&&void 0!==n?n:[];return!s&&r.length>1?r.filter((e=>"Domain"!==e.Type)):r})),je=e=>e.tenants.searchValue,fe=(0,ue.Mz)([xe,de.yV,je],((e,t,s)=>{let n=((e,t)=>t===de.s$.ALL?e:e.filter((e=>e.Overall&&e.Overall!==v.m.Green)))(e,t);return n=((e,t)=>e.filter((e=>{const s=new RegExp(he()(t),"i");return s.test(e.Name||"")||s.test(e.controlPlaneName)})))(n,s),n}));var Ne=s(51114),ye=s(56839),be=s(28232);const we=JSON.parse('{"create-database":"Create database","remove":"Remove","edit":"Edit"}'),_e=(0,C.g4)("ydb-tenants-table",{en:we}),Ce=(0,g.cn)("tenants"),ke=({additionalTenantsProps:e,scrollContainerRef:t})=>{const s=(0,M.YQ)(),r=(0,be.H)(),[l]=(0,M.Nt)(),{currentData:a,isFetching:o,error:i}=ge.GJ.useGetTenantsInfoQuery({clusterName:r},{pollingInterval:l}),c=o&&void 0===a,d=(0,G.sH)()&&void 0!==Ne.J.onCreateDB,u=(0,G.g7)()&&void 0!==Ne.J.onEditDB,m=(0,G.TW)()&&void 0!==Ne.J.onDeleteDB,h=(0,M.N4)((e=>xe(e,r))),v=(0,M.N4)(je),g=(0,M.N4)((e=>fe(e,r))),p=(0,M.N4)(de.yV),x=e=>{s((0,de.$u)(e))},j=e=>{s((0,ge.gB)(e))};return(0,b.jsx)("div",{className:Ce("table-wrapper"),children:(0,b.jsxs)(te.L,{fullHeight:!0,children:[(0,b.jsx)(te.L.Controls,{renderExtraControls:()=>d&&r&&!c?(0,b.jsxs)(J.$,{view:"action",onClick:()=>{var e;return null===(e=Ne.J.onCreateDB)||void 0===e?void 0:e.call(Ne.J,{clusterName:r})},className:Ce("create-database"),children:[(0,b.jsx)(y.I,{data:P.A}),_e("create-database")]}):null,children:(0,b.jsxs)(n.Fragment,{children:[(0,b.jsx)(ee.v,{value:v,onChange:j,placeholder:"Database name",className:Ce("search")}),(0,b.jsx)(K.k,{value:p,onChange:x}),(0,b.jsx)(Y.T,{total:h.length,current:(null===g||void 0===g?void 0:g.length)||0,label:"Databases",loading:c})]})}),i?(0,b.jsx)(q.o,{error:i}):null,(0,b.jsx)(te.L.Table,{scrollContainerRef:t,loading:c,scrollDependencies:[v,p],children:a?(()=>{const t=[{name:"Name",header:"Database",render:({row:t})=>(0,b.jsx)(ce,{tenant:t,additionalTenantsProps:e}),width:440,sortable:!0,defaultOrder:F.Ay.DESCENDING},{name:"controlPlaneName",header:"Name",render:({row:e})=>e.controlPlaneName,width:200,sortable:!0,defaultOrder:F.Ay.DESCENDING},{name:"Type",width:200,resizeMinWidth:150,render:({row:e})=>"Serverless"!==e.Type?e.Type:(0,b.jsxs)("div",{className:Ce("type"),children:[(0,b.jsx)("span",{className:Ce("type-value"),children:e.Type}),(0,b.jsx)(J.$,{className:Ce("type-button"),onClick:()=>j(e.sharedTenantName||""),children:"Show shared"})]})},{name:"State",width:150,render:({row:e})=>e.State?e.State.toLowerCase():"\u2014",customStyle:()=>({textTransform:"capitalize"})},{name:"cpu",header:"CPU",width:80,render:({row:e})=>e.cpu&&e.cpu>1e4?(0,ye.iM)(e.cpu):"\u2014",align:F.Ay.RIGHT,defaultOrder:F.Ay.DESCENDING},{name:"memory",header:"Memory",width:120,render:({row:e})=>e.memory?(0,ye.vX)(e.memory):"\u2014",align:F.Ay.RIGHT,defaultOrder:F.Ay.DESCENDING},{name:"storage",header:"Storage",width:120,render:({row:e})=>e.storage?(0,ye.vX)(e.storage):"\u2014",align:F.Ay.RIGHT,defaultOrder:F.Ay.DESCENDING},{name:"nodesCount",header:"Nodes",width:100,render:({row:e})=>e.nodesCount?(0,ye.ZV)(e.nodesCount):"\u2014",align:F.Ay.RIGHT,defaultOrder:F.Ay.DESCENDING},{name:"groupsCount",header:"Groups",width:100,render:({row:e})=>e.groupsCount?(0,ye.ZV)(e.groupsCount):"\u2014",align:F.Ay.RIGHT,defaultOrder:F.Ay.DESCENDING},{name:"PoolStats",header:"Pools",width:100,resizeMinWidth:60,sortAccessor:({PoolStats:e=[]})=>e.reduce(((e,t)=>e+(t.Usage||0)),0),defaultOrder:F.Ay.DESCENDING,align:F.Ay.LEFT,render:({row:e})=>(0,b.jsx)(Q._,{pools:e.PoolStats})}];if(r&&(m||u)){const e=function({clusterName:e,isEditDBAvailable:t,isDeleteDBAvailable:s}){return{name:"actions",header:"",width:40,resizeable:!1,align:F.Ay.CENTER,render:({row:n})=>{const r=[];return t&&r.push({text:_e("edit"),iconStart:(0,b.jsx)(U.A,{}),action:()=>{var t;null===(t=Ne.J.onEditDB)||void 0===t||t.call(Ne.J,{clusterName:e,databaseData:n})}}),s&&r.push({text:_e("remove"),iconStart:(0,b.jsx)(W.A,{}),action:()=>{var t;null===(t=Ne.J.onDeleteDB)||void 0===t||t.call(Ne.J,{clusterName:e,databaseData:n})},className:Ce("remove-db")}),r.length?(0,b.jsx)(H.r,{items:r}):null}}}({clusterName:r,isDeleteDBAvailable:m,isEditDBAvailable:u});t.push(e)}return 0===g.length&&p!==de.s$.ALL?(0,b.jsx)(Z.v,{name:"thumbsUp",width:"200"}):(0,b.jsx)(X.l,{columnsWidthLSKey:"databasesTableColumnsWidth",data:g,columns:t,settings:ve.N3,emptyDataMessage:"No such tenants"})})():null})]})})};var Se=s(44433),Ee=s(74321),Te=s(98167),Ve=s(15298),Oe=s(18143);const De=(0,g.cn)("ydb-cluster-versions-bar"),Ae=({versionsValues:e=[],size:t="s",progressClassName:s})=>(0,b.jsxs)("div",{className:De(),children:[(0,b.jsx)(Oe.k,{value:100,stack:e,size:t,className:s}),(0,b.jsx)("div",{className:De("versions"),children:e.map(((t,s)=>(0,b.jsx)("div",{className:De("version-title"),style:{color:t.color},title:t.version,children:`${t.version}${s===e.length-1?"":","}`},t.version)))})]});var Le=s(63126),Ge=s(78762),ze=s(88655);function Ie(e){return[(0,Ge._E)(),(0,Ge.Nh)(e),(0,Ge.jl)(),(0,Ge.pH)(),(0,Ge.fr)(),(0,Ge.ID)()]}const Me=({nodes:e})=>{const t=(0,ze.E)(),s=Ie({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef});return(0,b.jsx)(X.l,{columnsWidthLSKey:"versionsTableColumnsWidth",data:e,columns:s,settings:ve.N3})};var Re=s(96873);const Be=(0,g.cn)("ydb-versions-nodes-tree-title"),$e=({title:e,nodes:t,items:s,versionColor:n,versionsValues:r})=>{let l;return l=s?s.reduce(((e,t)=>t.nodes?e+t.nodes.length:e),0):t?t.length:0,(0,b.jsxs)("div",{className:Be("overview"),children:[(0,b.jsxs)("div",{className:Be("overview-container"),children:[n?(0,b.jsx)("div",{className:Be("version-color"),style:{background:n}}):null,e?(0,b.jsxs)("span",{className:Be("overview-title"),children:[e,(0,b.jsx)(Re.b,{text:e,size:"s",className:Be("clipboard-button"),view:"normal"})]}):null]}),(0,b.jsxs)("div",{className:Be("overview-info"),children:[(0,b.jsxs)("div",{children:[(0,b.jsx)("span",{className:Be("info-value"),children:l}),(0,b.jsx)("span",{className:Be("info-label",{margin:"left"}),children:"Nodes"})]}),r?(0,b.jsxs)("div",{className:Be("version-progress"),children:[(0,b.jsx)("span",{className:Be("info-label",{margin:"right"}),children:"Versions"}),(0,b.jsx)(Oe.k,{size:"s",value:100,stack:r})]}):null]})]})},Pe=(0,g.cn)("ydb-versions-grouped-node-tree"),Ue=({title:e,nodes:t,items:s,expanded:r=!1,versionColor:l,versionsValues:a,level:o=0})=>{const[i,c]=n.useState(!1);n.useEffect((()=>{c(r)}),[r]);const d=(0,b.jsx)($e,{title:e,nodes:t,items:s,versionColor:l,versionsValues:a}),u=()=>{c((e=>!e))};return s?(0,b.jsx)("div",{className:Pe({"first-level":0===o}),children:(0,b.jsx)(Le.G,{name:d,collapsed:!i,hasArrow:!0,onClick:u,onArrowClick:u,children:s.map(((e,t)=>(0,b.jsx)(Ue,{title:e.title,nodes:e.nodes,expanded:r,versionColor:e.versionColor,level:o+1},t)))},e)}):(0,b.jsx)("div",{className:Pe({"first-level":0===o}),children:(0,b.jsx)(Le.G,{name:d,collapsed:!i,hasArrow:!0,onClick:u,onArrowClick:u,children:(0,b.jsx)("div",{className:Pe("dt-wrapper"),children:(0,b.jsx)(Me,{nodes:t||[]})})},e)})};var We=s(78018),Fe=s.n(We),Je=s(38596);const He=.5,Ye=(e=[],t)=>{const s=e.reduce(((e,t)=>(t.Version&&(e[t.Version]?e[t.Version]=e[t.Version]+1:e[t.Version]=1),e)),{});return Ze(Object.keys(s).map((n=>{const r=s[n]/e.length*100;return{title:n,version:n,color:null===t||void 0===t?void 0:t.get((0,Je.U)(n)),value:re+t.count),0);return Ze(e.map((e=>{const s=e.count/n*100;return{title:e.name,version:e.name,color:null===t||void 0===t?void 0:t.get((0,Je.U)(e.name)),value:s{n+=e.value,e.value>t&&(t=e.value,s=r)}));const r=[...e];return r[s]={...e[s],value:t+100-n},r}let Qe=function(e){return e.VERSION="Version",e.TENANT="Database",e.STORAGE="Storage",e}({});const Ke=(e,t)=>{var s;return(null===(s=e.title)||void 0===s?void 0:s.localeCompare(t.title||""))||-1},Xe=(e,t,s)=>{if(e&&e.length){if(s===Qe.VERSION){const s=Fe()(e,"Version");return Object.keys(s).map((e=>{const n=s[e].filter(nt),r=Fe()(n,"Tenants"),l=Object.keys(r).map((e=>({title:e,nodes:r[e]}))).sort(Ke);return l.length?{title:e,items:l,versionColor:null===t||void 0===t?void 0:t.get((0,Je.U)(e))}:null})).filter((e=>Boolean(e)))}{const s=e.filter(nt),n=Fe()(s,"Tenants");return Object.keys(n).map((e=>{const s=Ye(n[e],t),r=Fe()(n[e],"Version"),l=Object.keys(r).map((e=>({title:e,nodes:r[e],versionColor:null===t||void 0===t?void 0:t.get((0,Je.U)(e))})));return l.length?{title:e,items:l,versionsValues:s}:null})).filter((e=>Boolean(e))).sort(Ke)}}},et=(e,t)=>{if(!e||!e.length)return;const s=e.filter(st),n=Fe()(s,"Version");return Object.keys(n).map((e=>({title:e,nodes:n[e],versionColor:null===t||void 0===t?void 0:t.get((0,Je.U)(e))})))},tt=(e,t)=>{if(!e||!e.length)return;const s=e.filter((e=>!st(e)&&!nt(e)&&e.Version)),n=Fe()(s,"Version");return Object.keys(n).map((e=>({title:e,nodes:n[e],versionColor:null===t||void 0===t?void 0:t.get((0,Je.U)(e))})))};function st(e){var t;return Boolean(null===(t=e.Roles)||void 0===t?void 0:t.includes("Storage"))}function nt(e){return Boolean(e.Tenants)}const rt=JSON.parse('{"title_overall":"Overall","title_storage":"Storage nodes","title_database":"Database nodes","title_other":"Other nodes"}'),lt=(0,C.g4)("ydb-versions",{en:rt});var at=s(44992),ot=s(39567),it=s(98730),ct=s(40537),dt=s(66592);const ut=({cluster:e,versionToColor:t,clusterLoading:s})=>{const{currentData:r}=Ve.s.useGetNodesQuery((0,it.L)(e)||s?at.hT:{tablets:!1,fieldsRequired:["SystemState","SubDomainKey"],group:"Version"});return n.useMemo((()=>{if((0,it.L)(e)&&e.MapVersions){return qe(Object.entries(e.MapVersions).map((([e,t])=>({name:e,count:t}))),t,e.NodesTotal)}return r?Array.isArray(r.NodeGroups)?qe(r.NodeGroups,t,null===e||void 0===e?void 0:e.NodesTotal):Ye(r.Nodes,t):[]}),[r,t,e])};function mt(e){const t=function(){const[e]=(0,i.useQueryParam)("clusterName",i.StringParam),t=(0,M.N4)((e=>e.singleClusterMode)),{data:s}=ot.ub.useGetClustersListQuery(void 0,{skip:t});return n.useMemo((()=>{if(t)return;const n=(s||[]).find((t=>t.name===e)),r=(null===n||void 0===n?void 0:n.versions)||[];return()=>(0,ct.Vm)((0,ct.HD)(r))}),[t,s,e])}();return n.useMemo((()=>t?t():(0,dt._n)(null===e||void 0===e?void 0:e.Versions)),[null===e||void 0===e?void 0:e.Versions,t])}const ht=(0,g.cn)("ydb-versions");function vt({cluster:e,loading:t}){const[s]=(0,M.Nt)(),{currentData:n,isLoading:r}=Ve.s.useGetNodesQuery({tablets:!1,fieldsRequired:["SystemState","SubDomainKey"]},{pollingInterval:s}),l=mt(),a=ut({cluster:e,versionToColor:l,clusterLoading:t});return(0,b.jsx)(Te.r,{loading:t||r,children:(0,b.jsx)(gt,{versionsValues:a,nodes:null===n||void 0===n?void 0:n.Nodes,versionToColor:l})})}function gt({versionsValues:e,nodes:t,versionToColor:s}){const[r,l]=n.useState(Qe.VERSION),[a,o]=n.useState(!1),i=e=>{l(e)},c=Xe(t,s,r),d=et(t,s),u=tt(t,s),m=null!==d&&void 0!==d&&d.length?(0,b.jsxs)(n.Fragment,{children:[(0,b.jsx)("h4",{children:lt("title_storage")}),d.map((({title:e,nodes:t,items:s,versionColor:n})=>(0,b.jsx)(Ue,{title:e,nodes:t,items:s,versionColor:n},`storage-nodes-${e}`)))]}):null,h=null!==c&&void 0!==c&&c.length?(0,b.jsxs)(n.Fragment,{children:[(0,b.jsx)("h4",{children:lt("title_database")}),(0,b.jsxs)("div",{className:ht("controls"),children:[(0,b.jsxs)("div",{className:ht("group"),children:[(0,b.jsx)("span",{className:ht("label"),children:"Group by:"}),(0,b.jsxs)(Se.a,{value:r,onUpdate:i,children:[(0,b.jsx)(Se.a.Option,{value:Qe.TENANT,children:Qe.TENANT}),(0,b.jsx)(Se.a.Option,{value:Qe.VERSION,children:Qe.VERSION})]})]}),(0,b.jsx)(Ee.S,{className:ht("checkbox"),onChange:()=>o((e=>!e)),checked:a,children:"All expanded"})]}),c.map((({title:e,nodes:t,items:s,versionColor:n,versionsValues:r})=>(0,b.jsx)(Ue,{title:e,nodes:t,items:s,expanded:a,versionColor:n,versionsValues:r},`tenant-nodes-${e}`)))]}):null,v=null!==u&&void 0!==u&&u.length?(0,b.jsxs)(n.Fragment,{children:[(0,b.jsx)("h4",{children:lt("title_other")}),u.map((({title:e,nodes:t,items:s,versionColor:n,versionsValues:r})=>(0,b.jsx)(Ue,{title:e,nodes:t,items:s,versionColor:n,versionsValues:r},`other-nodes-${e}`)))]}):null,g=(0,b.jsxs)(n.Fragment,{children:[(0,b.jsx)("h4",{children:lt("title_overall")}),(0,b.jsx)("div",{className:ht("overall-wrapper"),children:(0,b.jsx)(Ae,{progressClassName:ht("overall-progress"),versionsValues:e.filter((e=>"unknown"!==e.title)),size:"m"})})]});return(0,b.jsxs)("div",{className:ht(),children:[g,m,h,v]})}var pt=s(79522),xt=s(98089),jt=s(33705),ft=s(7435),Nt=s(80967),yt=s(42655);const bt=JSON.parse('{"erasure":"Erasure","allocated":"Allocated","available":"Available","usage":"Usage","label_nodes-state":"Nodes state","label_dc":"Nodes data centers","links":"Links","link_cores":"Coredumps","link_logging":"Logging","link_slo-logs":"SLO Logs","context_cores":"cores","title_cpu":"CPU","title_storage":"Storage","title_storage-groups":"Storage Groups","title_memory":"Memory","title_network":"Network","title_links":"Links","title_details":"Details","label_overview":"Overview","label_load":"Load","context_of":"of","context_cpu":"CPU load","context_memory":"Memory used","context_storage":["Storage: {{count}} group","Storage: {{count}} groups","Storage: {{count}} groups","Storage: {{count}} groups"],"context_network":"Network Evaluation","context_cpu-description":"CPU load is calculated as the cumulative usage across all actor system pools on all nodes in the cluster","context_memory-description":"Memory usage is the total memory consumed by all nodes in the cluster","context_storage-description":"Storage usage is a cumulative usage of raw disk space of all media types","context_network-description":"Network usage is the average outgoing bandwidth usage across all nodes in the cluster"}'),wt=(0,C.g4)("ydb-cluster",{en:bt});var _t=s(87842);const Ct=(0,g.cn)("cluster-info");var kt=s(41650);function St(){const{cores:e,logging:t}=(0,z.Zd)();return n.useMemo((()=>{const s=[],n=function(e){try{const t=(0,kt.qF)(e);if(t&&"object"===typeof t&&"url"in t&&"string"===typeof t.url)return t.url}catch{}}(e),{logsUrl:r,sloLogsUrl:l}=function(e){try{const t=(0,kt.qF)(e);if(t&&"object"===typeof t){return{logsUrl:"url"in t&&"string"===typeof t.url?t.url:void 0,sloLogsUrl:"slo_logs_url"in t&&"string"===typeof t.slo_logs_url?t.slo_logs_url:void 0}}}catch{}return{}}(t);return n&&s.push({title:wt("link_cores"),url:n}),r&&s.push({title:wt("link_logging"),url:r}),l&&s.push({title:wt("link_slo-logs"),url:l}),s}),[e,t])}var Et=s(15132);const Tt=({tags:e,className:t="",gap:s=1})=>(0,b.jsx)(m.s,{className:t,gap:s,wrap:"wrap",alignItems:"center",children:e&&e.map(((e,t)=>(0,b.jsx)(u.J,{size:"s",children:e},t)))});var Vt=s(46549),Ot=s(35736);const Dt=(0,g.cn)("ydb-disk-groups-stats"),At={good:"success",warning:"warning",danger:"danger"};function Lt({stats:e,storageType:t}){const{erasure:s,allocatedSize:n,availableSize:r}=e,l=(0,Vt.fn)(Math.max(n,r)),a=(0,Vt.z3)({value:n,size:l}),o=(0,Vt.z3)({value:r,size:l}),i=Math.floor(n/(n+r)*100),c=[{name:wt("erasure"),content:s},{name:wt("allocated"),content:a},{name:wt("available"),content:o},{name:wt("usage"),content:(0,b.jsxs)(m.s,{gap:2,alignItems:"center",children:[(0,b.jsx)(Oe.k,{theme:At[(0,Ot.w)({fillWidth:i})],className:Dt("progress"),value:i,size:"s"}),(0,b.jsxs)(xt.E,{color:"secondary",children:[i,"%"]})]})}];return(0,b.jsxs)(m.s,{direction:"column",gap:3,className:Dt(),children:[(0,b.jsxs)(xt.E,{variant:"body-2",children:[t," ",(0,b.jsx)(xt.E,{color:"secondary",variant:"body-2",children:`${(0,ye.ZV)(e.createdGroups)} ${wt("context_of")} ${(0,ye.ZV)(e.totalGroups)}`})]}),(0,b.jsx)(se.u,{nameMaxWidth:160,children:c.map((({name:e,content:t})=>(0,b.jsx)(se.u.Item,{name:e,children:t},e)))})]})}const Gt={Green:5,Blue:4,Yellow:3,Orange:2,Red:1,Grey:0},zt=(e,t)=>{var s;const r=[],l=(e=>{if((0,it.L)(e)&&e.MapDataCenters)return Object.entries(e.MapDataCenters).map((([e,t])=>(0,b.jsxs)(n.Fragment,{children:[e," : ",(0,ye.ZV)(t)]},e)))})(e);if(null!==l&&void 0!==l&&l.length&&r.push({label:wt("label_dc"),value:(0,b.jsx)(Tt,{tags:l,gap:2,className:Ct("dc")})}),(0,it.L)(e)&&e.MapNodeStates){const t=Object.entries(e.MapNodeStates);t.sort(((e,t)=>Gt[t[0]]-Gt[e[0]]));const s=t.map((([e,t])=>(0,b.jsx)(D.Label,{withStatusName:!1,status:e,size:"s",iconSize:12,children:(0,ye.ZV)(t)},e)));r.push({label:wt("label_nodes-state"),value:(0,b.jsx)(m.s,{gap:2,children:s})})}return r.push({label:wt("label_load"),value:(0,b.jsx)(Et.O,{value:null===e||void 0===e?void 0:e.LoadAverage,capacity:null!==(s=null===e||void 0===e?void 0:e.RealNumberOfCpus)&&void 0!==s?s:null===e||void 0===e?void 0:e.NumberOfCpus})}),r.push(...t),r};const It=({cluster:e,loading:t,error:s,additionalClusterProps:n={},groupStats:r={}})=>{const{info:l=[],links:a=[]}=n,o=St(),i=a.concat(o),c=zt(null!==e&&void 0!==e?e:{},l),d=()=>t?(0,b.jsx)(yt.y,{className:Ct("skeleton"),rows:4}):s&&!e?null:(0,b.jsxs)(se.u,{nameMaxWidth:200,children:[c.map((({label:e,value:t})=>(0,b.jsx)(se.u.Item,{name:e,children:t},e))),i.length>0&&(0,b.jsx)(se.u.Item,{name:wt("title_links"),children:(0,b.jsx)(m.s,{direction:"column",gap:2,children:i.map((({title:e,url:t})=>(0,b.jsx)(ae.K,{title:e,url:t},e)))})})]}),u=(0,_t.lq)(r);return(0,b.jsxs)(m.s,{gap:4,direction:"column",className:Ct(),children:[s?(0,b.jsx)(q.o,{error:s,className:Ct("error")}):null,(0,b.jsxs)(Mt,{children:[(0,b.jsx)(xt.E,{as:"div",variant:"subheader-2",className:Ct("section-title"),children:wt("title_details")}),d()]}),(()=>{const e=function(e){const t=[];return Object.entries(e).forEach((([e,s])=>{Object.values(s).forEach((s=>{t.push((0,b.jsx)(Lt,{stats:s,storageType:e},`${e}|${s.erasure}`))}))})),t}(r);return t?null:(0,b.jsxs)(Mt,{children:[(0,b.jsxs)(xt.E,{as:"div",variant:"subheader-2",className:Ct("section-title"),children:[wt("title_storage-groups")," ",(0,b.jsx)(xt.E,{variant:"subheader-2",color:"secondary",children:(0,ye.ZV)(u)})]}),(0,b.jsx)(m.s,{gap:2,children:e})]})})()]})};function Mt({children:e}){return(0,b.jsx)(m.s,{direction:"column",gap:3,children:e})}const Rt=(0,g.cn)("ydb-doughnut-metrics");function Bt({status:e,fillWidth:t,children:s,className:n}){let r=3.6*t,l="var(--doughnut-color)",a="var(--doughnut-backdrop-color)";return r>360&&(r-=360,a="var(--doughnut-color)",l="var(--doughnut-overlap-color)"),(0,b.jsx)("div",{className:Rt(null,n),children:(0,b.jsx)("div",{style:{background:`conic-gradient(${l} 0deg ${r}deg, ${a} ${r}deg 360deg)`},className:Rt("doughnut",{status:e}),children:(0,b.jsx)("div",{className:Rt("text-wrapper"),children:s})})})}Bt.Legend=function({children:e,variant:t="subheader-3",color:s="primary",note:n}){return(0,b.jsxs)(m.s,{gap:1,alignItems:"center",children:[(0,b.jsx)(xt.E,{variant:t,color:s,className:Rt("legend"),as:"div",children:e}),n&&(0,b.jsx)(h.H,{className:Rt("legend-note"),children:n})]})},Bt.Value=function({children:e,variant:t="subheader-2"}){return(0,b.jsx)(xt.E,{variant:t,className:Rt("value"),children:e})};var $t=s(70043);const Pt=(0,g.cn)("ydb-cluster-dashboard"),Ut={good:v.m.Green,warning:v.m.Yellow,danger:v.m.Red};function Wt({children:e,className:t,collapsed:s}){return(0,b.jsx)(m.s,{gap:"6",alignItems:"center",className:Pt("card",{collapsed:s},t),children:e})}function Ft({title:e,children:t,legend:s,collapsed:n,...r}){const{main:l,secondary:a,note:o}=s;if(n){const{status:t,fillWidth:s}=r,n=s.toFixed(s>0?0:1);return(0,b.jsx)(D.Label,{withStatusName:!1,status:Ut[t],children:`${e} : ${n}%`})}return(0,b.jsxs)(Wt,{children:[(0,b.jsx)(Bt,{...r,children:t}),(0,b.jsxs)("div",{className:Pt("legend-wrapper"),children:[l&&(0,b.jsx)(Bt.Legend,{children:l}),a&&(0,b.jsx)(Bt.Legend,{color:"secondary",note:o,variant:"body-1",children:a})]})]})}function Jt({collapsed:e}){return(0,b.jsx)(Wt,{className:Pt("skeleton-wrapper"),collapsed:e,children:(0,b.jsx)($t.E,{className:Pt("skeleton")})})}function Ht({collapsed:e}){return(0,b.jsxs)(n.Fragment,{children:[(0,b.jsx)(Jt,{collapsed:e}),(0,b.jsx)(Jt,{collapsed:e}),(0,b.jsx)(Jt,{collapsed:e})]})}function Yt({colorizeProgress:e=!0,warningThreshold:t,dangerThreshold:s,inverseColorize:n=!1,fillWidth:r}){const l=Math.max(r,.5);return{status:(0,Ot.w)({fillWidth:r,warningThreshold:t,dangerThreshold:s,colorizeProgress:e,inverseColorize:n}),percents:(0,ye.l9)(r/100),fill:l}}function qt({value:e,capacity:t,legendFormatter:s,...n}){const r=parseFloat(String(e)),l=parseFloat(String(t));let a=r/l*100||0;a=a>100?100:a;const o=s({value:r,capacity:l});return{...Yt({fillWidth:a,...n}),legend:o}}function Zt({value:e,capacity:t}){let s=[];return s=t<1e4?[(0,ye.ZV)(Math.round(e)),(0,ye.ZV)(Math.round(t))]:(0,ye.Nd)(e,t,void 0,"",!0),`${s[0]} ${wt("context_of")} ${s[1]} ${wt("context_cores")}`}function Qt({collapsed:e,value:t,capacity:s,...n}){const{status:r,percents:l,legend:a,fill:o}=qt({value:t,capacity:s,legendFormatter:Zt,...n});return(0,b.jsx)(Ft,{collapsed:e,status:r,fillWidth:o,title:wt("title_cpu"),legend:{main:a,secondary:wt("context_cpu"),note:wt("context_cpu-description")},children:(0,b.jsx)(Bt.Value,{children:l})})}function Kt({value:e,capacity:t}){const s=(0,ye.j9)(e,t,void 0,"\n");return`${s[0]} ${wt("context_of")} ${s[1]}`}function Xt({value:e,capacity:t,collapsed:s,...n}){const{status:r,percents:l,legend:a,fill:o}=qt({value:e,capacity:t,legendFormatter:Kt,...n});return(0,b.jsx)(Ft,{status:r,fillWidth:o,title:wt("title_memory"),collapsed:s,legend:{main:a,secondary:wt("context_memory"),note:wt("context_memory-description")},children:(0,b.jsx)(Bt.Value,{children:l})})}function es({percentsValue:e,throughput:t,collapsed:s,...n}){const[r]=(0,Nt.i)(ve._X);if(!r)return null;const{status:l,percents:a,fill:o}=Yt({fillWidth:100*e,...n}),i=(c=t,(0,Vt.z3)({value:c,withSpeedLabel:!0}));var c;return(0,b.jsx)(Ft,{status:l,fillWidth:o,title:wt("title_network"),collapsed:s,legend:{main:i,secondary:wt("context_network"),note:wt("context_network-description")},children:(0,b.jsx)(Bt.Value,{children:a})})}function ts({value:e,capacity:t}){const s=(0,ye.j9)(e,t,void 0,"\n");return`${s[0]} ${wt("context_of")} ${s[1]}`}function ss({value:e,capacity:t,groups:s,collapsed:n,...r}){const{status:l,percents:a,legend:o,fill:i}=qt({value:e,capacity:t,legendFormatter:ts,...r});return(0,b.jsx)(Ft,{status:l,fillWidth:i,title:wt("title_storage"),collapsed:n,legend:{main:o,secondary:wt("context_storage",{count:s}),note:wt("context_storage-description")},children:(0,b.jsx)(Bt.Value,{children:a})})}var ns;function rs(){return rs=Object.assign?Object.assign.bind():function(e){for(var t=1;ts(!t),children:[(0,b.jsx)(pt.E.Summary,{children:s=>(0,b.jsxs)("div",{...s,className:Pt("disclosure-summary"),children:[(0,b.jsxs)(m.s,{alignItems:"center",justifyContent:"space-between",width:"100%",children:[(0,b.jsxs)(m.s,{gap:2,alignItems:"center",children:[(0,b.jsx)(y.I,{data:ls,size:16}),(0,b.jsx)(xt.E,{variant:"body-2",color:"primary",className:Pt("title"),children:wt("label_overview")})]}),!t&&(0,b.jsx)(os,{...e,collapsed:!0})]}),(0,b.jsx)(jt.I,{size:16,direction:s.expanded?"top":"bottom"})]})}),(0,b.jsx)(os,{...e}),(0,b.jsx)(It,{...e})]})})}function os({collapsed:e,...t}){return(0,G.fp)()?(0,b.jsx)(m.s,{wrap:!0,className:Pt("dashboard-wrapper",{collapsed:e}),children:(0,b.jsx)(is,{...t,collapsed:e})}):null}function is({cluster:e,groupStats:t={},loading:s,collapsed:n}){if(s)return(0,b.jsx)(Ht,{collapsed:n});const r=[];if((0,it.L)(e)){const{CoresUsed:t,NumberOfCpus:s,CoresTotal:l}=e,a=null!==l&&void 0!==l?l:s;(0,ft.f8)(t)&&(0,ft.f8)(a)&&r.push((0,b.jsx)(Qt,{value:t,capacity:a,collapsed:n},"cores"))}const{StorageTotal:l,StorageUsed:a}=e;if((0,ft.f8)(l)&&(0,ft.f8)(a)){const e=(0,_t.lq)(t);r.push((0,b.jsx)(ss,{value:a,capacity:l,groups:e,collapsed:n},"storage"))}const{MemoryTotal:o,MemoryUsed:i}=e;if((0,ft.f8)(o)&&(0,ft.f8)(i)&&r.push((0,b.jsx)(Xt,{value:i,capacity:o,collapsed:n},"memory")),(0,it.E)(e)){const{NetworkUtilization:t,NetworkWriteThroughput:s}=e;(0,ft.f8)(t)&&r.push((0,b.jsx)(es,{percentsValue:t,throughput:s,collapsed:n},"network"))}return r}const cs=(0,g.cn)("ydb-cluster");function ds({additionalClusterProps:e,additionalTenantsProps:t,additionalNodesProps:s}){const d=n.useRef(null),u=(0,G.fp)(),[m]=(0,M.Nt)(),h=(0,M.YQ)(),g=function(){const e=(0,M.YQ)(),t=(0,M.N4)((e=>e.cluster.defaultClusterTab)),s=(0,o.W5)(L.Ay.cluster),{activeTab:r}=(null===s||void 0===s?void 0:s.params)||{};let l;l=(0,_t.eC)(r)?r:t;return n.useEffect((()=>{l!==t&&e((0,z.Yv)(l))}),[l,t,e]),l}(),[{clusterName:p,backend:x}]=(0,i.useQueryParams)({clusterName:i.StringParam,backend:i.StringParam}),j=(0,M.N4)((e=>(0,z.zR)(e,null!==p&&void 0!==p?p:void 0))),{title:f}=(0,z.Zd)(),N=null!==f&&void 0!==f?f:j,{data:{clusterData:y,groupsStats:w}={},isLoading:_,error:C}=z.Zh.useGetClusterInfoQuery(null!==p&&void 0!==p?p:void 0,{pollingInterval:m}),k=C&&"object"===typeof C?C:void 0,S=(0,M.N4)((e=>(0,z.ds)(e,null!==p&&void 0!==p?p:void 0)));n.useEffect((()=>{h((0,I.g)("cluster",{}))}),[h]);const T=n.useMemo((()=>_t.bn.find((({id:e})=>e===g))),[g]);return(0,b.jsxs)("div",{className:cs(),ref:d,children:[(0,b.jsx)(a.mg,{defaultTitle:`${N} \u2014 YDB Monitoring`,titleTemplate:`%s \u2014 ${N} \u2014 YDB Monitoring`,children:T?(0,b.jsx)("title",{children:T.title}):null}),(0,b.jsx)("div",{className:cs("header"),children:(()=>{if(_)return(0,b.jsx)(r.E,{className:cs("title-skeleton")});const e=(null===y||void 0===y?void 0:y.Overall)||v.m.Grey;return(0,b.jsxs)(D,{className:cs("title"),children:[N,(0,b.jsx)(D.Label,{status:e,note:E[e]})]})})()}),(0,b.jsx)("div",{className:cs("sticky-wrapper"),children:(0,b.jsx)(c.E,{className:cs("auto-refresh-control")})}),u&&(0,b.jsx)("div",{className:cs("dashboard"),children:(0,b.jsx)(as,{cluster:null!==y&&void 0!==y?y:{},groupStats:w,loading:_,error:k||(null===y||void 0===y?void 0:y.error),additionalClusterProps:e})}),(0,b.jsx)("div",{className:cs("tabs-sticky-wrapper"),children:(0,b.jsx)(l.t,{size:"l",allowNotSelected:!0,activeTab:g,items:_t.bn,wrapTo:({id:e},t)=>{const s=(0,_t.a)(e,{clusterName:p,backend:x});return(0,b.jsx)(A.E,{to:s,onClick:()=>{h((0,z.Yv)(e))},children:t},e)}})}),(0,b.jsx)("div",{className:cs("content"),children:(0,b.jsxs)(o.dO,{children:[(0,b.jsx)(o.qh,{path:(0,L.a3)((0,_t.a)(_t.Bi.tablets)).pathname,children:(0,b.jsx)($.Q,{loading:_,tablets:S,scrollContainerRef:d})}),(0,b.jsx)(o.qh,{path:(0,L.a3)((0,_t.a)(_t.Bi.tenants)).pathname,children:(0,b.jsx)(ke,{additionalTenantsProps:t,scrollContainerRef:d})}),(0,b.jsx)(o.qh,{path:(0,L.a3)((0,_t.a)(_t.Bi.nodes)).pathname,children:(0,b.jsx)(R.G,{scrollContainerRef:d,additionalNodesProps:s})}),(0,b.jsx)(o.qh,{path:(0,L.a3)((0,_t.a)(_t.Bi.storage)).pathname,children:(0,b.jsx)(B.z,{scrollContainerRef:d})}),(0,b.jsx)(o.qh,{path:(0,L.a3)((0,_t.a)(_t.Bi.versions)).pathname,children:(0,b.jsx)(vt,{cluster:y,loading:_})}),(0,b.jsx)(o.qh,{render:()=>(0,b.jsx)(o.rd,{to:(0,L.a3)((0,_t.a)(g))})})]})})]})}},42655:(e,t,s)=>{s.d(t,{y:()=>d});var n=s(59284),r=s(89169),l=s(77506),a=s(66781),o=s(60712);const i=(0,l.cn)("ydb-info-viewer-skeleton"),c=()=>(0,o.jsxs)("div",{className:i("label"),children:[(0,o.jsx)(r.E,{className:i("label__text")}),(0,o.jsx)("div",{className:i("label__dots")})]}),d=({rows:e=8,className:t,delay:s=600})=>{const[l]=(0,a.y)(s);let d=(0,o.jsxs)(n.Fragment,{children:[(0,o.jsx)(c,{}),(0,o.jsx)(r.E,{className:i("value")})]});return l||(d=null),(0,o.jsx)("div",{className:i(null,t),children:[...new Array(e)].map(((e,t)=>(0,o.jsx)("div",{className:i("row"),children:d},`skeleton-row-${t}`)))})}},70043:(e,t,s)=>{s.d(t,{E:()=>a});var n=s(89169),r=s(66781),l=s(60712);const a=({delay:e=600,className:t})=>{const[s]=(0,r.y)(e);return s?(0,l.jsx)(n.E,{className:t}):null}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/35803.0104654b.chunk.js b/ydb/core/viewer/monitoring/static/js/35803.0104654b.chunk.js new file mode 100644 index 000000000000..6384fd34c163 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35803.0104654b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[35803],{35803:(e,t,r)=>{r.d(t,{default:()=>a});var n=r(54710);const a=r.n(n)()},54710:e=>{function t(e){e.languages.xojo={comment:{pattern:/(?:'|\/\/|Rem\b).+/i,greedy:!0},string:{pattern:/"(?:""|[^"])*"/,greedy:!0},number:[/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:E[+-]?\d+)?/i,/&[bchou][a-z\d]+/i],directive:{pattern:/#(?:Else|ElseIf|Endif|If|Pragma)\b/i,alias:"property"},keyword:/\b(?:AddHandler|App|Array|As(?:signs)?|Auto|Boolean|Break|By(?:Ref|Val)|Byte|Call|Case|Catch|CFStringRef|CGFloat|Class|Color|Const|Continue|CString|Currency|CurrentMethodName|Declare|Delegate|Dim|Do(?:uble|wnTo)?|Each|Else(?:If)?|End|Enumeration|Event|Exception|Exit|Extends|False|Finally|For|Function|Get|GetTypeInfo|Global|GOTO|If|Implements|In|Inherits|Int(?:8|16|32|64|eger|erface)?|Lib|Loop|Me|Module|Next|Nil|Object|Optional|OSType|ParamArray|Private|Property|Protected|PString|Ptr|Raise(?:Event)?|ReDim|RemoveHandler|Return|Select(?:or)?|Self|Set|Shared|Short|Single|Soft|Static|Step|String|Sub|Super|Text|Then|To|True|Try|Ubound|UInt(?:8|16|32|64|eger)?|Until|Using|Var(?:iant)?|Wend|While|WindowPtr|WString)\b/i,operator:/<[=>]?|>=?|[+\-*\/\\^=]|\b(?:AddressOf|And|Ctype|IsA?|Mod|New|Not|Or|WeakAddressOf|Xor)\b/i,punctuation:/[.,;:()]/}}e.exports=t,t.displayName="xojo",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/35888.e5062b23.chunk.js b/ydb/core/viewer/monitoring/static/js/35888.e5062b23.chunk.js new file mode 100644 index 000000000000..1879e5608189 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/35888.e5062b23.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 35888.e5062b23.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[35888],{35888:(e,r,n)=>{n.r(r),n.d(r,{conf:()=>t,language:()=>s});var t={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#%\^\&\*\(\)\=\$\-\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{blockComment:["###","###"],lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},s={defaultToken:"",ignoreCase:!0,tokenPostfix:".coffee",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],regEx:/\/(?!\/\/)(?:[^\/\\]|\\.)*\/[igm]*/,keywords:["and","or","is","isnt","not","on","yes","@","no","off","true","false","null","this","new","delete","typeof","in","instanceof","return","throw","break","continue","debugger","if","else","switch","for","while","do","try","catch","finally","class","extends","super","undefined","then","unless","until","loop","of","by","when"],symbols:/[=>{function t(e){e.languages.mermaid={comment:{pattern:/%%.*/,greedy:!0},style:{pattern:/^([ \t]*(?:classDef|linkStyle|style)[ \t]+[\w$-]+[ \t]+)\w.*[^\s;]/m,lookbehind:!0,inside:{property:/\b\w[\w-]*(?=[ \t]*:)/,operator:/:/,punctuation:/,/}},"inter-arrow-label":{pattern:/([^<>ox.=-])(?:-[-.]|==)(?![<>ox.=-])[ \t]*(?:"[^"\r\n]*"|[^\s".=-](?:[^\r\n.=-]*[^\s.=-])?)[ \t]*(?:\.+->?|--+[->]|==+[=>])(?![<>ox.=-])/,lookbehind:!0,greedy:!0,inside:{arrow:{pattern:/(?:\.+->?|--+[->]|==+[=>])$/,alias:"operator"},label:{pattern:/^([\s\S]{2}[ \t]*)\S(?:[\s\S]*\S)?/,lookbehind:!0,alias:"property"},"arrow-head":{pattern:/^\S+/,alias:["arrow","operator"]}}},arrow:[{pattern:/(^|[^{}|o.-])[|}][|o](?:--|\.\.)[|o][|{](?![{}|o.-])/,lookbehind:!0,alias:"operator"},{pattern:/(^|[^<>ox.=-])(?:[ox]?|(?:==+|--+|-\.*-)[>ox]|===+|---+|-\.+-)(?![<>ox.=-])/,lookbehind:!0,alias:"operator"},{pattern:/(^|[^<>()x-])(?:--?(?:>>|[x>)])(?![<>()x])|(?:<<|[x<(])--?(?!-))/,lookbehind:!0,alias:"operator"},{pattern:/(^|[^<>|*o.-])(?:[*o]--|--[*o]|<\|?(?:--|\.\.)|(?:--|\.\.)\|?>|--|\.\.)(?![<>|*o.-])/,lookbehind:!0,alias:"operator"}],label:{pattern:/(^|[^|<])\|(?:[^\r\n"|]|"[^"\r\n]*")+\|/,lookbehind:!0,greedy:!0,alias:"property"},text:{pattern:/(?:[(\[{]+|\b>)(?:[^\r\n"()\[\]{}]|"[^"\r\n]*")+(?:[)\]}]+|>)/,alias:"string"},string:{pattern:/"[^"\r\n]*"/,greedy:!0},annotation:{pattern:/<<(?:abstract|choice|enumeration|fork|interface|join|service)>>|\[\[(?:choice|fork|join)\]\]/i,alias:"important"},keyword:[{pattern:/(^[ \t]*)(?:action|callback|class|classDef|classDiagram|click|direction|erDiagram|flowchart|gantt|gitGraph|graph|journey|link|linkStyle|pie|requirementDiagram|sequenceDiagram|stateDiagram|stateDiagram-v2|style|subgraph)(?![\w$-])/m,lookbehind:!0,greedy:!0},{pattern:/(^[ \t]*)(?:activate|alt|and|as|autonumber|deactivate|else|end(?:[ \t]+note)?|loop|opt|par|participant|rect|state|note[ \t]+(?:over|(?:left|right)[ \t]+of))(?![\w$-])/im,lookbehind:!0,greedy:!0}],entity:/#[a-z0-9]+;/,operator:{pattern:/(\w[ \t]*)&(?=[ \t]*\w)|:::|:/,lookbehind:!0},punctuation:/[(){};]/}}e.exports=t,t.displayName="mermaid",t.aliases=[]},35958:(e,t,a)=>{a.d(t,{default:()=>o});var r=a(21001);const o=a.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/36374.16f4dcdb.chunk.js b/ydb/core/viewer/monitoring/static/js/36374.16f4dcdb.chunk.js new file mode 100644 index 000000000000..5bdea00cf576 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/36374.16f4dcdb.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 36374.16f4dcdb.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[36374],{36374:(e,o,t)=>{t.r(o),t.d(o,{conf:()=>n,language:()=>s});var n={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"},{open:'"',close:'"'},{open:"(*",close:"*)"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"},{open:'"',close:'"'},{open:"(*",close:"*)"}]},s={defaultToken:"",tokenPostfix:".cameligo",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["abs","assert","block","Bytes","case","Crypto","Current","else","failwith","false","for","fun","if","in","let","let%entry","let%init","List","list","Map","map","match","match%nat","mod","not","operation","Operation","of","record","Set","set","sender","skip","source","String","then","to","true","type","with"],typeKeywords:["int","unit","string","tz","nat","bool"],operators:["=",">","<","<=",">=","<>",":",":=","and","mod","or","+","-","*","/","@","&","^","%","->","<-","&&","||"],symbols:/[=><:@\^&|+\-*\/\^%]+/,tokenizer:{root:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\$[0-9a-fA-F]{1,16}/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'/,"string","@string"],[/'[^\\']'/,"string"],[/'/,"string.invalid"],[/\#\d+/,"string"]],comment:[[/[^\(\*]+/,"comment"],[/\*\)/,"comment","@pop"],[/\(\*/,"comment"]],string:[[/[^\\']+/,"string"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"],[/\(\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3822.00ab6aaa.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/36374.16f4dcdb.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/3822.00ab6aaa.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/36374.16f4dcdb.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/3638.ee3efb24.chunk.js b/ydb/core/viewer/monitoring/static/js/3638.ee3efb24.chunk.js deleted file mode 100644 index 73970a0af834..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3638.ee3efb24.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 3638.ee3efb24.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3638],{13638:(e,t,s)=>{s.r(t),s.d(t,{conf:()=>r,language:()=>o});var r={comments:{lineComment:"#",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}]},o={defaultToken:"",tokenPostfix:".hcl",keywords:["var","local","path","for_each","any","string","number","bool","true","false","null","if ","else ","endif ","for ","in","endfor"],operators:["=",">=","<=","==","!=","+","-","*","/","%","&&","||","!","<",">","?","...",":"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"operator","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\d[\d']*/,"number"],[/\d/,"number"],[/[;,.]/,"delimiter"],[/"/,"string","@string"],[/'/,"invalid"]],heredoc:[[/<<[-]*\s*["]?([\w\-]+)["]?/,{token:"string.heredoc.delimiter",next:"@heredocBody.$1"}]],heredocBody:[[/([\w\-]+)$/,{cases:{"$1==$S2":[{token:"string.heredoc.delimiter",next:"@popall"}],"@default":"string.heredoc"}}],[/./,"string.heredoc"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"],[/#.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],string:[[/\$\{/,{token:"delimiter",next:"@stringExpression"}],[/[^\\"\$]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@popall"]],stringInsideExpression:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],stringExpression:[[/\}/,{token:"delimiter",next:"@pop"}],[/"/,"string","@stringInsideExpression"],{include:"@terraform"}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3653.06b5272c.chunk.js b/ydb/core/viewer/monitoring/static/js/3653.06b5272c.chunk.js deleted file mode 100644 index 6150b3f05900..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3653.06b5272c.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3653],{63653:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"zh-hk",months:"\u4e00\u6708_\u4e8c\u6708_\u4e09\u6708_\u56db\u6708_\u4e94\u6708_\u516d\u6708_\u4e03\u6708_\u516b\u6708_\u4e5d\u6708_\u5341\u6708_\u5341\u4e00\u6708_\u5341\u4e8c\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),weekdays:"\u661f\u671f\u65e5_\u661f\u671f\u4e00_\u661f\u671f\u4e8c_\u661f\u671f\u4e09_\u661f\u671f\u56db_\u661f\u671f\u4e94_\u661f\u671f\u516d".split("_"),weekdaysShort:"\u9031\u65e5_\u9031\u4e00_\u9031\u4e8c_\u9031\u4e09_\u9031\u56db_\u9031\u4e94_\u9031\u516d".split("_"),weekdaysMin:"\u65e5_\u4e00_\u4e8c_\u4e09_\u56db_\u4e94_\u516d".split("_"),ordinal:function(_,e){return"W"===e?_+"\u9031":_+"\u65e5"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5 HH:mm",LLLL:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm"},relativeTime:{future:"%s\u5167",past:"%s\u524d",s:"\u5e7e\u79d2",m:"\u4e00\u5206\u9418",mm:"%d \u5206\u9418",h:"\u4e00\u5c0f\u6642",hh:"%d \u5c0f\u6642",d:"\u4e00\u5929",dd:"%d \u5929",M:"\u4e00\u500b\u6708",MM:"%d \u500b\u6708",y:"\u4e00\u5e74",yy:"%d \u5e74"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3672.12436dd6.chunk.js b/ydb/core/viewer/monitoring/static/js/3672.12436dd6.chunk.js deleted file mode 100644 index f98ab6480aa5..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3672.12436dd6.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3672],{53672:function(e,a,t){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=a(e);function u(e,a,t,u){var s={s:["m\xf5ne sekundi","m\xf5ni sekund","paar sekundit"],m:["\xfche minuti","\xfcks minut"],mm:["%d minuti","%d minutit"],h:["\xfche tunni","tund aega","\xfcks tund"],hh:["%d tunni","%d tundi"],d:["\xfche p\xe4eva","\xfcks p\xe4ev"],M:["kuu aja","kuu aega","\xfcks kuu"],MM:["%d kuu","%d kuud"],y:["\xfche aasta","aasta","\xfcks aasta"],yy:["%d aasta","%d aastat"]};return a?(s[t][2]?s[t][2]:s[t][1]).replace("%d",e):(u?s[t][0]:s[t][1]).replace("%d",e)}var s={name:"et",weekdays:"p\xfchap\xe4ev_esmasp\xe4ev_teisip\xe4ev_kolmap\xe4ev_neljap\xe4ev_reede_laup\xe4ev".split("_"),weekdaysShort:"P_E_T_K_N_R_L".split("_"),weekdaysMin:"P_E_T_K_N_R_L".split("_"),months:"jaanuar_veebruar_m\xe4rts_aprill_mai_juuni_juuli_august_september_oktoober_november_detsember".split("_"),monthsShort:"jaan_veebr_m\xe4rts_apr_mai_juuni_juuli_aug_sept_okt_nov_dets".split("_"),ordinal:function(e){return e+"."},weekStart:1,relativeTime:{future:"%s p\xe4rast",past:"%s tagasi",s:u,m:u,mm:u,h:u,hh:u,d:u,dd:"%d p\xe4eva",M:u,MM:u,y:u,yy:u},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm"}};return t.default.locale(s,null,!0),s}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/36754.f9faf9f5.chunk.js b/ydb/core/viewer/monitoring/static/js/36754.f9faf9f5.chunk.js new file mode 100644 index 000000000000..2c67977ffd65 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/36754.f9faf9f5.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[36754],{36754:(n,e,a)=>{a.d(e,{default:()=>t});var i=a(87687);const t=a.n(i)()},87687:n=>{function e(n){!function(n){var e="(?:ALPHA|BIT|CHAR|CR|CRLF|CTL|DIGIT|DQUOTE|HEXDIG|HTAB|LF|LWSP|OCTET|SP|VCHAR|WSP)";n.languages.abnf={comment:/;.*/,string:{pattern:/(?:%[is])?"[^"\n\r]*"/,greedy:!0,inside:{punctuation:/^%[is]/}},range:{pattern:/%(?:b[01]+-[01]+|d\d+-\d+|x[A-F\d]+-[A-F\d]+)/i,alias:"number"},terminal:{pattern:/%(?:b[01]+(?:\.[01]+)*|d\d+(?:\.\d+)*|x[A-F\d]+(?:\.[A-F\d]+)*)/i,alias:"number"},repetition:{pattern:/(^|[^\w-])(?:\d*\*\d*|\d+)/,lookbehind:!0,alias:"operator"},definition:{pattern:/(^[ \t]*)(?:[a-z][\w-]*|<[^<>\r\n]*>)(?=\s*=)/m,lookbehind:!0,alias:"keyword",inside:{punctuation:/<|>/}},"core-rule":{pattern:RegExp("(?:(^|[^<\\w-])"+e+"|<"+e+">)(?![\\w-])","i"),lookbehind:!0,alias:["rule","constant"],inside:{punctuation:/<|>/}},rule:{pattern:/(^|[^<\w-])[a-z][\w-]*|<[^<>\r\n]*>/i,lookbehind:!0,inside:{punctuation:/<|>/}},operator:/=\/?|\//,punctuation:/[()\[\]]/}}(n)}n.exports=e,e.displayName="abnf",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/36786.ca3962c1.chunk.js b/ydb/core/viewer/monitoring/static/js/36786.ca3962c1.chunk.js new file mode 100644 index 000000000000..ce0e072ae902 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/36786.ca3962c1.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[36786],{36786:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-il",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3679.e293221d.chunk.js b/ydb/core/viewer/monitoring/static/js/3679.e293221d.chunk.js deleted file mode 100644 index cba9cb058a31..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3679.e293221d.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3679],{86060:function(e,_,t){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=_(e),r={name:"lb",weekdays:"Sonndeg_M\xe9indeg_D\xebnschdeg_M\xebttwoch_Donneschdeg_Freideg_Samschdeg".split("_"),months:"Januar_Februar_M\xe4erz_Abr\xebll_Mee_Juni_Juli_August_September_Oktober_November_Dezember".split("_"),weekStart:1,weekdaysShort:"So._M\xe9._D\xeb._M\xeb._Do._Fr._Sa.".split("_"),monthsShort:"Jan._Febr._Mrz._Abr._Mee_Jun._Jul._Aug._Sept._Okt._Nov._Dez.".split("_"),weekdaysMin:"So_M\xe9_D\xeb_M\xeb_Do_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"H:mm [Auer]",LTS:"H:mm:ss [Auer]",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm [Auer]",LLLL:"dddd, D. MMMM YYYY H:mm [Auer]"}};return t.default.locale(r,null,!0),r}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3702.778880f9.chunk.js b/ydb/core/viewer/monitoring/static/js/3702.778880f9.chunk.js deleted file mode 100644 index dfe1a4a34492..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3702.778880f9.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 3702.778880f9.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3702],{23702:(e,_,t)=>{t.r(_),t.d(_,{conf:()=>r,language:()=>i});var r={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},i={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["AES128","AES256","ALL","ALLOWOVERWRITE","ANALYSE","ANALYZE","AND","ANY","ARRAY","AS","ASC","AUTHORIZATION","AZ64","BACKUP","BETWEEN","BINARY","BLANKSASNULL","BOTH","BYTEDICT","BZIP2","CASE","CAST","CHECK","COLLATE","COLUMN","CONSTRAINT","CREATE","CREDENTIALS","CROSS","CURRENT_DATE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURRENT_USER_ID","DEFAULT","DEFERRABLE","DEFLATE","DEFRAG","DELTA","DELTA32K","DESC","DISABLE","DISTINCT","DO","ELSE","EMPTYASNULL","ENABLE","ENCODE","ENCRYPT","ENCRYPTION","END","EXCEPT","EXPLICIT","FALSE","FOR","FOREIGN","FREEZE","FROM","FULL","GLOBALDICT256","GLOBALDICT64K","GRANT","GROUP","GZIP","HAVING","IDENTITY","IGNORE","ILIKE","IN","INITIALLY","INNER","INTERSECT","INTO","IS","ISNULL","JOIN","LANGUAGE","LEADING","LEFT","LIKE","LIMIT","LOCALTIME","LOCALTIMESTAMP","LUN","LUNS","LZO","LZOP","MINUS","MOSTLY16","MOSTLY32","MOSTLY8","NATURAL","NEW","NOT","NOTNULL","NULL","NULLS","OFF","OFFLINE","OFFSET","OID","OLD","ON","ONLY","OPEN","OR","ORDER","OUTER","OVERLAPS","PARALLEL","PARTITION","PERCENT","PERMISSIONS","PLACING","PRIMARY","RAW","READRATIO","RECOVER","REFERENCES","RESPECT","REJECTLOG","RESORT","RESTORE","RIGHT","SELECT","SESSION_USER","SIMILAR","SNAPSHOT","SOME","SYSDATE","SYSTEM","TABLE","TAG","TDES","TEXT255","TEXT32K","THEN","TIMESTAMP","TO","TOP","TRAILING","TRUE","TRUNCATECOLUMNS","UNION","UNIQUE","USER","USING","VERBOSE","WALLET","WHEN","WHERE","WITH","WITHOUT"],operators:["AND","BETWEEN","IN","LIKE","NOT","OR","IS","NULL","INTERSECT","UNION","INNER","JOIN","LEFT","OUTER","RIGHT"],builtinFunctions:["current_schema","current_schemas","has_database_privilege","has_schema_privilege","has_table_privilege","age","current_time","current_timestamp","localtime","isfinite","now","ascii","get_bit","get_byte","set_bit","set_byte","to_ascii","approximate percentile_disc","avg","count","listagg","max","median","min","percentile_cont","stddev_samp","stddev_pop","sum","var_samp","var_pop","bit_and","bit_or","bool_and","bool_or","cume_dist","first_value","lag","last_value","lead","nth_value","ratio_to_report","dense_rank","ntile","percent_rank","rank","row_number","case","coalesce","decode","greatest","least","nvl","nvl2","nullif","add_months","at time zone","convert_timezone","current_date","date_cmp","date_cmp_timestamp","date_cmp_timestamptz","date_part_year","dateadd","datediff","date_part","date_trunc","extract","getdate","interval_cmp","last_day","months_between","next_day","sysdate","timeofday","timestamp_cmp","timestamp_cmp_date","timestamp_cmp_timestamptz","timestamptz_cmp","timestamptz_cmp_date","timestamptz_cmp_timestamp","timezone","to_timestamp","trunc","abs","acos","asin","atan","atan2","cbrt","ceil","ceiling","checksum","cos","cot","degrees","dexp","dlog1","dlog10","exp","floor","ln","log","mod","pi","power","radians","random","round","sin","sign","sqrt","tan","to_hex","bpcharcmp","btrim","bttext_pattern_cmp","char_length","character_length","charindex","chr","concat","crc32","func_sha1","initcap","left and rights","len","length","lower","lpad and rpads","ltrim","md5","octet_length","position","quote_ident","quote_literal","regexp_count","regexp_instr","regexp_replace","regexp_substr","repeat","replace","replicate","reverse","rtrim","split_part","strpos","strtol","substring","textlen","translate","trim","upper","cast","convert","to_char","to_date","to_number","json_array_length","json_extract_array_element_text","json_extract_path_text","current_setting","pg_cancel_backend","pg_terminate_backend","set_config","current_database","current_user","current_user_id","pg_backend_pid","pg_last_copy_count","pg_last_copy_id","pg_last_query_id","pg_last_unload_count","session_user","slice_num","user","version","abbrev","acosd","any","area","array_agg","array_append","array_cat","array_dims","array_fill","array_length","array_lower","array_ndims","array_position","array_positions","array_prepend","array_remove","array_replace","array_to_json","array_to_string","array_to_tsvector","array_upper","asind","atan2d","atand","bit","bit_length","bound_box","box","brin_summarize_new_values","broadcast","cardinality","center","circle","clock_timestamp","col_description","concat_ws","convert_from","convert_to","corr","cosd","cotd","covar_pop","covar_samp","current_catalog","current_query","current_role","currval","cursor_to_xml","diameter","div","encode","enum_first","enum_last","enum_range","every","family","format","format_type","generate_series","generate_subscripts","get_current_ts_config","gin_clean_pending_list","grouping","has_any_column_privilege","has_column_privilege","has_foreign_data_wrapper_privilege","has_function_privilege","has_language_privilege","has_sequence_privilege","has_server_privilege","has_tablespace_privilege","has_type_privilege","height","host","hostmask","inet_client_addr","inet_client_port","inet_merge","inet_same_family","inet_server_addr","inet_server_port","isclosed","isempty","isopen","json_agg","json_object","json_object_agg","json_populate_record","json_populate_recordset","json_to_record","json_to_recordset","jsonb_agg","jsonb_object_agg","justify_days","justify_hours","justify_interval","lastval","left","line","localtimestamp","lower_inc","lower_inf","lpad","lseg","make_date","make_interval","make_time","make_timestamp","make_timestamptz","masklen","mode","netmask","network","nextval","npoints","num_nonnulls","num_nulls","numnode","obj_description","overlay","parse_ident","path","pclose","percentile_disc","pg_advisory_lock","pg_advisory_lock_shared","pg_advisory_unlock","pg_advisory_unlock_all","pg_advisory_unlock_shared","pg_advisory_xact_lock","pg_advisory_xact_lock_shared","pg_backup_start_time","pg_blocking_pids","pg_client_encoding","pg_collation_is_visible","pg_column_size","pg_conf_load_time","pg_control_checkpoint","pg_control_init","pg_control_recovery","pg_control_system","pg_conversion_is_visible","pg_create_logical_replication_slot","pg_create_physical_replication_slot","pg_create_restore_point","pg_current_xlog_flush_location","pg_current_xlog_insert_location","pg_current_xlog_location","pg_database_size","pg_describe_object","pg_drop_replication_slot","pg_export_snapshot","pg_filenode_relation","pg_function_is_visible","pg_get_constraintdef","pg_get_expr","pg_get_function_arguments","pg_get_function_identity_arguments","pg_get_function_result","pg_get_functiondef","pg_get_indexdef","pg_get_keywords","pg_get_object_address","pg_get_owned_sequence","pg_get_ruledef","pg_get_serial_sequence","pg_get_triggerdef","pg_get_userbyid","pg_get_viewdef","pg_has_role","pg_identify_object","pg_identify_object_as_address","pg_index_column_has_property","pg_index_has_property","pg_indexam_has_property","pg_indexes_size","pg_is_in_backup","pg_is_in_recovery","pg_is_other_temp_schema","pg_is_xlog_replay_paused","pg_last_committed_xact","pg_last_xact_replay_timestamp","pg_last_xlog_receive_location","pg_last_xlog_replay_location","pg_listening_channels","pg_logical_emit_message","pg_logical_slot_get_binary_changes","pg_logical_slot_get_changes","pg_logical_slot_peek_binary_changes","pg_logical_slot_peek_changes","pg_ls_dir","pg_my_temp_schema","pg_notification_queue_usage","pg_opclass_is_visible","pg_operator_is_visible","pg_opfamily_is_visible","pg_options_to_table","pg_postmaster_start_time","pg_read_binary_file","pg_read_file","pg_relation_filenode","pg_relation_filepath","pg_relation_size","pg_reload_conf","pg_replication_origin_create","pg_replication_origin_drop","pg_replication_origin_oid","pg_replication_origin_progress","pg_replication_origin_session_is_setup","pg_replication_origin_session_progress","pg_replication_origin_session_reset","pg_replication_origin_session_setup","pg_replication_origin_xact_reset","pg_replication_origin_xact_setup","pg_rotate_logfile","pg_size_bytes","pg_size_pretty","pg_sleep","pg_sleep_for","pg_sleep_until","pg_start_backup","pg_stat_file","pg_stop_backup","pg_switch_xlog","pg_table_is_visible","pg_table_size","pg_tablespace_databases","pg_tablespace_location","pg_tablespace_size","pg_total_relation_size","pg_trigger_depth","pg_try_advisory_lock","pg_try_advisory_lock_shared","pg_try_advisory_xact_lock","pg_try_advisory_xact_lock_shared","pg_ts_config_is_visible","pg_ts_dict_is_visible","pg_ts_parser_is_visible","pg_ts_template_is_visible","pg_type_is_visible","pg_typeof","pg_xact_commit_timestamp","pg_xlog_location_diff","pg_xlog_replay_pause","pg_xlog_replay_resume","pg_xlogfile_name","pg_xlogfile_name_offset","phraseto_tsquery","plainto_tsquery","point","polygon","popen","pqserverversion","query_to_xml","querytree","quote_nullable","radius","range_merge","regexp_matches","regexp_split_to_array","regexp_split_to_table","regr_avgx","regr_avgy","regr_count","regr_intercept","regr_r2","regr_slope","regr_sxx","regr_sxy","regr_syy","right","row_security_active","row_to_json","rpad","scale","set_masklen","setseed","setval","setweight","shobj_description","sind","sprintf","statement_timestamp","stddev","string_agg","string_to_array","strip","substr","table_to_xml","table_to_xml_and_xmlschema","tand","text","to_json","to_regclass","to_regnamespace","to_regoper","to_regoperator","to_regproc","to_regprocedure","to_regrole","to_regtype","to_tsquery","to_tsvector","transaction_timestamp","ts_debug","ts_delete","ts_filter","ts_headline","ts_lexize","ts_parse","ts_rank","ts_rank_cd","ts_rewrite","ts_stat","ts_token_type","tsquery_phrase","tsvector_to_array","tsvector_update_trigger","tsvector_update_trigger_column","txid_current","txid_current_snapshot","txid_snapshot_xip","txid_snapshot_xmax","txid_snapshot_xmin","txid_visible_in_snapshot","unnest","upper_inc","upper_inf","variance","width","width_bucket","xml_is_well_formed","xml_is_well_formed_content","xml_is_well_formed_document","xmlagg","xmlcomment","xmlconcat","xmlelement","xmlexists","xmlforest","xmlparse","xmlpi","xmlroot","xmlserialize","xpath","xpath_exists"],builtinVariables:[],pseudoColumns:[],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@keywords":"keyword","@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],complexIdentifiers:[[/"/,{token:"identifier.quote",next:"@quotedIdentifier"}]],quotedIdentifier:[[/[^"]+/,"identifier"],[/""/,"identifier"],[/"/,{token:"identifier.quote",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/371.adb771f2.chunk.js b/ydb/core/viewer/monitoring/static/js/371.adb771f2.chunk.js deleted file mode 100644 index 9b1a4cc8af77..000000000000 --- a/ydb/core/viewer/monitoring/static/js/371.adb771f2.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[371],{56735:(e,s,a)=>{a.d(s,{Q:()=>N});var t=a(87184),l=a(92459),i=a(78668),n=a(7435),d=a(46549),o=a(77506),r=a(56839),c=a(31684),u=a(90182),v=a(18863),p=a(25196),h=a(15132),m=a(33775),g=a(48372);const k=JSON.parse('{"type":"Type","path":"Path","guid":"GUID","serial-number":"Serial Number","shared-with-os":"SharedWithOs","drive-status":"Drive Status","state":"State","device":"Device","realtime":"Realtime","space":"Space","slots":"Slots","log-size":"Log Size","system-size":"System Size","links":"Links","developer-ui":"Developer UI","pdisk-page":"PDisk page","yes":"Yes"}'),f=(0,g.g4)("ydb-pDisk-info",{en:k});var b=a(60712);const x=(0,o.cn)("ydb-pdisk-info");function N({pDisk:e,nodeId:s,withPDiskPageLink:a,className:o}){const g=(0,u.N4)(i._5),[k,N,j,I]=function({pDisk:e,nodeId:s,withPDiskPageLink:a,isUserAllowedToMakeChanges:t}){const{PDiskId:i,Path:o,Guid:u,Category:v,Type:g,Device:k,Realtime:N,State:j,SerialNumber:I,TotalSize:S,AllocatedSize:D,StatusV2:w,NumActiveSlots:y,ExpectedSlotCount:z,LogUsedSize:T,LogTotalSize:P,SystemSize:E,SharedWithOs:V}=e||{},R=[];(0,n.f8)(v)&&R.push({label:f("type"),value:g}),(0,n.f8)(o)&&R.push({label:f("path"),value:o}),(0,n.f8)(u)&&R.push({label:f("guid"),value:u}),I&&R.push({label:f("serial-number"),value:I}),(0,n.f8)(V)&&R.push({label:f("shared-with-os"),value:f("yes")});const A=[];(0,n.f8)(w)&&A.push({label:f("drive-status"),value:w}),(0,n.f8)(j)&&A.push({label:f("state"),value:j}),(0,n.f8)(k)&&A.push({label:f("device"),value:(0,b.jsx)(m.k,{status:k})}),(0,n.f8)(N)&&A.push({label:f("realtime"),value:(0,b.jsx)(m.k,{status:N})});const O=[];O.push({label:f("space"),value:(0,b.jsx)(h.O,{value:D,capacity:S,formatValues:r.vX,colorizeProgress:!0})}),(0,n.f8)(y)&&(0,n.f8)(z)&&O.push({label:f("slots"),value:(0,b.jsx)(h.O,{value:y,capacity:z})}),(0,n.f8)(T)&&(0,n.f8)(P)&&O.push({label:f("log-size"),value:(0,b.jsx)(h.O,{value:T,capacity:P,formatValues:r.vX})}),(0,n.f8)(E)&&O.push({label:f("system-size"),value:(0,d.z3)({value:E})});const C=[];if((a||t)&&(0,n.f8)(i)&&(0,n.f8)(s)){const e=(0,l.Ck)(i,s),n=(0,c.ar)({nodeId:s,pDiskId:i});C.push({label:f("links"),value:(0,b.jsxs)("span",{className:x("links"),children:[a&&(0,b.jsx)(p.K,{title:f("pdisk-page"),url:e,external:!1}),t&&(0,b.jsx)(p.K,{title:f("developer-ui"),url:n})]})})}return[R,A,O,C]}({pDisk:e,nodeId:s,withPDiskPageLink:a,isUserAllowedToMakeChanges:g});return(0,b.jsxs)(t.s,{className:o,gap:2,direction:"row",wrap:!0,children:[(0,b.jsxs)(t.s,{direction:"column",gap:2,width:500,children:[(0,b.jsx)(v.z,{info:k,renderEmptyState:()=>null}),(0,b.jsx)(v.z,{info:j,renderEmptyState:()=>null})]}),(0,b.jsxs)(t.s,{direction:"column",gap:2,width:500,children:[(0,b.jsx)(v.z,{info:N,renderEmptyState:()=>null}),(0,b.jsx)(v.z,{info:I,renderEmptyState:()=>null})]})]})}},59984:(e,s,a)=>{a.d(s,{Y:()=>o});a(59284);var t=a(87184),l=a(77506),i=a(60712);const n=(0,l.cn)("tag"),d=({text:e,type:s})=>(0,i.jsx)("div",{className:n({type:s}),children:e}),o=({tags:e,tagsType:s,className:a="",gap:l=1})=>(0,i.jsx)(t.s,{className:a,gap:l,wrap:"wrap",alignItems:"center",children:e&&e.map(((e,a)=>(0,i.jsx)(d,{text:e,type:s},a)))})},67440:(e,s,a)=>{a.d(s,{E:()=>N});a(59284);var t=a(92459),l=a(78668),i=a(7435),n=a(77506),d=a(56839),o=a(31684),r=a(7187),c=a(90182),u=a(41650),v=a(60073),p=a(25196),h=a(15132),m=a(33775),g=a(48372);const k=JSON.parse('{"slot-id":"VDisk Slot Id","pool-name":"Storage Pool Name","kind":"Kind","guid":"GUID","incarnation-guid":"Incarnation GUID","instance-guid":"Instance GUID","replication-status":"Replicated","state-status":"VDisk State","space-status":"Disk Space","fresh-rank-satisfaction":"Fresh Rank Satisfaction","level-rank-satisfaction":"Level Rank Satisfaction","front-queues":"Front Queues","has-unreadable-blobs":"Has Unreadable Blobs","size":"Size","read-throughput":"Read Throughput","write-throughput":"Write Throughput","links":"Links","vdisk-page":"VDisk Page","developer-ui":"Developer UI","yes":"Yes","no":"No","vdiks-title":"VDisk"}'),f=(0,g.g4)("ydb-vDisk-info",{en:k});var b=a(60712);const x=(0,n.cn)("ydb-vdisk-info");function N({data:e,withVDiskPageLink:s,withTitle:a,...n}){var r,g;const k=(0,c.N4)(l._5),{AllocatedSize:N,DiskSpace:I,FrontQueues:S,Guid:D,Replicated:w,VDiskState:y,VDiskSlotId:z,Kind:T,SatisfactionRank:P,AvailableSize:E,HasUnreadableBlobs:V,IncarnationGuid:R,InstanceGuid:A,StoragePoolName:O,ReadThroughput:C,WriteThroughput:L,PDiskId:U,NodeId:F}=e||{},M=[];var q,G;((0,i.f8)(z)&&M.push({label:f("slot-id"),value:z}),(0,i.f8)(O)&&M.push({label:f("pool-name"),value:O}),(0,i.f8)(y)&&M.push({label:f("state-status"),value:y}),Number(N)>=0&&Number(E)>=0&&M.push({label:f("size"),value:(0,b.jsx)(h.O,{value:N,capacity:Number(N)+Number(E),formatValues:d.vX,colorizeProgress:!0})}),(0,i.f8)(T)&&M.push({label:f("kind"),value:T}),(0,i.f8)(D)&&M.push({label:f("guid"),value:D}),(0,i.f8)(R)&&M.push({label:f("incarnation-guid"),value:R}),(0,i.f8)(A)&&M.push({label:f("instance-guid"),value:A}),(0,i.f8)(w)&&M.push({label:f("replication-status"),value:f(w?"yes":"no")}),(0,i.f8)(I)&&M.push({label:f("space-status"),value:(0,b.jsx)(m.k,{status:I})}),(0,i.f8)(null===P||void 0===P||null===(r=P.FreshRank)||void 0===r?void 0:r.Flag))&&M.push({label:f("fresh-rank-satisfaction"),value:(0,b.jsx)(m.k,{status:null===P||void 0===P||null===(q=P.FreshRank)||void 0===q?void 0:q.Flag})});(0,i.f8)(null===P||void 0===P||null===(g=P.LevelRank)||void 0===g?void 0:g.Flag)&&M.push({label:f("level-rank-satisfaction"),value:(0,b.jsx)(m.k,{status:null===P||void 0===P||null===(G=P.LevelRank)||void 0===G?void 0:G.Flag})});(0,i.f8)(S)&&M.push({label:f("front-queues"),value:(0,b.jsx)(m.k,{status:S})}),(0,i.f8)(V)&&M.push({label:f("has-unreadable-blobs"),value:f(V?"yes":"no")}),(0,i.f8)(C)&&M.push({label:f("read-throughput"),value:(0,u.O4)(C)}),(0,i.f8)(L)&&M.push({label:f("write-throughput"),value:(0,u.O4)(L)});if((0,i.f8)(U)&&(0,i.f8)(F)&&(0,i.f8)(z)){const e=[];if(s){const s=(0,t.yX)(z,U,F);e.push((0,b.jsx)(p.K,{title:f("vdisk-page"),url:s,external:!1},s))}if(k){const s=(0,o.Wg)({nodeId:F,pDiskId:U,vDiskSlotId:z});e.push((0,b.jsx)(p.K,{title:f("developer-ui"),url:s},s))}e.length&&M.push({label:f("links"),value:(0,b.jsx)("div",{className:x("links"),children:e})})}const _=e&&a?(0,b.jsx)(j,{data:e}):null;return(0,b.jsx)(v.z_,{info:M,title:_,...n})}function j({data:e}){return(0,b.jsxs)("div",{className:x("title"),children:[f("vdiks-title"),(0,b.jsx)(m.k,{status:(0,r.XY)(e.Severity)}),e.StringifiedId]})}},49020:(e,s,a)=>{a.r(s),a.d(s,{Node:()=>Ie});var t=a(59284),l=a(23871),i=a(61750),n=a(10755),d=a(52905),o=a(67087),r=a(90053),c=a(112),u=a(99991),v=a(78668),p=a(77506),h=a(31684),m=a(90182),g=a(10508),k=a(59984),f=a(60712);const b=(0,p.cn)("basic-node-viewer"),x=({node:e,additionalNodesProps:s,className:a})=>{const l=(0,m.N4)(v._5);let i;if(null!==s&&void 0!==s&&s.getNodeRef){const a=s.getNodeRef(e);i=a?(0,h.Un)(a):void 0}else if(e.NodeId){const s=(0,h.Kx)(e.NodeId);i=(0,h.Un)(s)}return(0,f.jsx)("div",{className:b(null,a),children:e?(0,f.jsxs)(t.Fragment,{children:[(0,f.jsx)("div",{className:b("title"),children:"Node"}),(0,f.jsx)(g.c,{status:e.SystemState,name:e.Host}),i&&l?(0,f.jsx)("a",{rel:"noopener noreferrer",className:b("link",{external:!0}),href:i,target:"_blank",children:(0,f.jsx)(u.I,{data:c.A})}):null,(0,f.jsxs)("div",{className:b("id"),children:[(0,f.jsx)("label",{className:b("label"),children:"NodeID"}),(0,f.jsx)("label",{children:e.NodeId})]}),e.DC&&(0,f.jsx)(k.Y,{tags:[e.DC]}),e.Roles&&(0,f.jsx)(k.Y,{tags:e.Roles,tagsType:"blue"})]}):(0,f.jsx)("div",{className:"error",children:"no data"})})};var N=a(44508),j=a(76086),I=a(18863);const S=(0,p.cn)("ydb-pool-usage"),D=e=>{let s="green";return e>60&&e<=80?s="yellow":e>80&&(s="red"),s},w=({data:e={}})=>{const{Threads:s,Name:a="Unknown",Usage:t=0}=e,l=t&&s,i=Math.floor(100*t),n=i>100?100:i;return(0,f.jsxs)("div",{className:S(),children:[(0,f.jsxs)("div",{className:S("info"),children:[(0,f.jsx)("div",{className:S("pool-name"),children:a}),l&&(0,f.jsxs)("div",{className:S("value"),children:[(0,f.jsxs)("div",{className:S("percents"),children:[i<1?"<1":i,"%"]}),(0,f.jsxs)("div",{className:S("threads"),children:["(\xd7",s,")"]})]})]}),(0,f.jsx)("div",{className:S("visual"),children:(0,f.jsx)("div",{className:S("usage-line",{type:D(n)}),style:{width:`${n}%`}})})]})};var y=a(15132),z=a(41826);const T=(0,p.cn)("full-node-viewer"),P=({node:e,className:s})=>{var a,t,l,i;const n=null===e||void 0===e||null===(a=e.Endpoints)||void 0===a?void 0:a.map((({Name:e,Address:s})=>({label:e,value:s}))),d=[];null!==e&&void 0!==e&&null!==(t=e.Tenants)&&void 0!==t&&t.length&&d.push({label:"Database",value:e.Tenants[0]}),d.push({label:"Version",value:null===e||void 0===e?void 0:e.Version},{label:"Uptime",value:(0,f.jsx)(z.p,{StartTime:null===e||void 0===e?void 0:e.StartTime,DisconnectTime:null===e||void 0===e?void 0:e.DisconnectTime})},{label:"DC",value:(null===e||void 0===e?void 0:e.DataCenterDescription)||(null===e||void 0===e?void 0:e.DC)},{label:"Rack",value:null===e||void 0===e?void 0:e.Rack});const o=null===e||void 0===e||null===(l=e.LoadAveragePercents)||void 0===l?void 0:l.map(((e,s)=>({label:j.GT[s],value:(0,f.jsx)(y.O,{value:e,percents:!0,colorizeProgress:!0,capacity:100})})));return(0,f.jsx)("div",{className:`${T()} ${s}`,children:e?(0,f.jsxs)("div",{className:T("common-info"),children:[(0,f.jsxs)("div",{children:[(0,f.jsx)("div",{className:T("section-title"),children:"Pools"}),(0,f.jsx)("div",{className:T("section",{pools:!0}),children:null===e||void 0===e||null===(i=e.PoolStats)||void 0===i?void 0:i.map(((e,s)=>(0,f.jsx)(w,{data:e},s)))})]}),n&&n.length&&(0,f.jsx)(I.z,{title:"Endpoints",className:T("section"),info:n}),(0,f.jsx)(I.z,{title:"Common info",className:T("section"),info:d}),(0,f.jsx)(I.z,{title:"Load average",className:T("section",{average:!0}),info:o})]}):(0,f.jsx)("div",{className:"error",children:"no data"})})};var E=a(52248),V=a(92459),R=a(67028),A=a(40174),O=a(21334),C=a(78034);const L=e=>{var s;if(null===(s=e.SystemStateInfo)||void 0===s||!s.length)return{};const a=e.SystemStateInfo[0];return(0,C.q1)(a)},U=O.F.injectEndpoints({endpoints:e=>({getNodeInfo:e.query({queryFn:async({nodeId:e},{signal:s})=>{try{const a=await window.api.viewer.getNodeInfo(e,{signal:s});return{data:L(a)}}catch(a){return{error:a}}},providesTags:["All"]}),getNodeStructure:e.query({queryFn:async({nodeId:e},{signal:s})=>{try{return{data:await window.api.viewer.getStorageInfo({nodeId:e},{signal:s})}}catch(a){return{error:a}}},providesTags:["All"]})}),overrideExisting:"throw"});var F=a(99936),M=a(76768),q=a(29819),G=a(905),_=a.n(G),Q=a(53850),K=a(56839),W=a(27295);const $=(0,Q.Mz)((e=>e),(e=>U.endpoints.getNodeStructure.select({nodeId:e}))),B=(0,Q.Mz)((e=>e),((e,s)=>$(s)),((e,s)=>s(e).data)),X=(0,Q.Mz)(((e,s)=>Number(s)),((e,s)=>B(e,s)),((e,s)=>{const a=null===s||void 0===s?void 0:s.StoragePools,t={};null===a||void 0===a||a.forEach((s=>{const a=s.Groups;null===a||void 0===a||a.forEach((a=>{var l;const i=null===(l=a.VDisks)||void 0===l?void 0:l.filter((s=>s.NodeId===e)).map(W.WT);null===i||void 0===i||i.forEach((a=>{var l;const i=(0,K.U9)(a.VDiskId),n=null===(l=a.PDisk)||void 0===l?void 0:l.PDiskId;t[String(n)]||(t[String(n)]={vDisks:{},...a.PDisk}),t[String(n)].vDisks[i]={...a,PDiskId:n,NodeId:e,StoragePoolName:s.Name}}))}))}));return Object.keys(t).reduce(((e,s)=>{const a=t[s].vDisks,l=Object.keys(a).reduce(((e,s,t)=>(e.push({...a[s],id:s,order:t}),e)),[]);return e[s]={...t[s],vDisks:l},e}),{})}));var Y=a(45720),H=a(4557),J=a(84476),Z=a(84375),ee=a(33705),se=a(56735),ae=a(33775),te=a(67440),le=a(54090),ie=a(67375),ne=a(7435),de=a(48372);const oe=JSON.parse('{"pdisk.developer-ui-button-title":"PDisk Developer UI page","vdisk.developer-ui-button-title":"VDisk Developer UI page"}'),re=JSON.parse('{"pdisk.developer-ui-button-title":"\u0421\u0442\u0440\u0430\u043d\u0438\u0446\u0430 PDisk \u0432 Developer UI","vdisk.developer-ui-button-title":"\u0421\u0442\u0440\u0430\u043d\u0438\u0446\u0430 VDisk \u0432 Developer UI"}'),ce=(0,de.g4)("ydb-node-page",{en:oe,ru:re}),ue=(0,p.cn)("kv-node-structure");function ve({label:e,value:s,className:a}){return(0,f.jsxs)("span",{className:ue("pdisk-title-item",a),children:[e&&(0,f.jsxs)("span",{className:ue("pdisk-title-item-label"),children:[e,":"]}),(0,f.jsx)("span",{className:ue("pdisk-title-item-value"),children:s})]})}const pe=(0,p.cn)("kv-node-structure");var he=function(e){return e.slotId="VDiskSlotId",e.VDiskState="VDiskState",e.Size="Size",e.Info="Info",e}(he||{});const me={VDiskSlotId:"Slot id",VDiskState:"Status",Size:"Size",Info:""};function ge({pDiskId:e,selectedVdiskId:s,nodeId:a,withDeveloperUILink:t}){return[{name:he.slotId,header:me[he.slotId],width:100,render:({row:l})=>{const i=l.VDiskSlotId;let n=null;return(0,ne.f8)(a)&&(0,ne.f8)(e)&&(0,ne.f8)(i)&&(n=(0,h.Wg)({nodeId:a,pDiskId:e,vDiskSlotId:i})),(0,f.jsxs)("div",{className:pe("vdisk-id",{selected:l.id===s}),children:[(0,f.jsx)("span",{children:i}),n&&t?(0,f.jsx)(J.$,{size:"s",className:pe("external-button",{hidden:!0}),href:n,target:"_blank",title:ce("vdisk.developer-ui-button-title"),children:(0,f.jsx)(u.I,{data:c.A})}):null]})},align:H.Ay.LEFT},{name:he.VDiskState,header:me[he.VDiskState],width:70,render:({row:e})=>(0,f.jsx)(ae.k,{status:e.VDiskState===ie.W.OK?le.m.Green:le.m.Red}),sortAccessor:e=>e.VDiskState===ie.W.OK?1:0,align:H.Ay.CENTER},{name:he.Size,header:me[he.Size],width:170,render:({row:e})=>(0,f.jsx)(y.O,{value:e.AllocatedSize,capacity:Number(e.AllocatedSize)+Number(e.AvailableSize),formatValues:K.vX,colorizeProgress:!0}),sortAccessor:e=>Number(e.AllocatedSize),align:H.Ay.CENTER},{name:he.Info,header:me[he.Info],width:70,render:({row:e})=>(0,f.jsx)(Z.A,{placement:["right"],content:(0,f.jsx)(te.E,{data:e,withTitle:!0,withVDiskPageLink:!0}),tooltipContentClassName:pe("vdisk-details"),children:(0,f.jsx)(J.$,{view:"flat-secondary",className:pe("vdisk-details-button",{selected:e.id===s}),children:(0,f.jsx)(u.I,{data:Y.A,size:18})})}),sortable:!1}]}function ke({id:e,data:s,selectedVdiskId:a,nodeId:l,unfolded:i}){const n=(0,m.N4)(v._5),[d,o]=t.useState(null!==i&&void 0!==i&&i),{TotalSize:r=0,AvailableSize:c=0,Device:u,PDiskId:p,Type:h,vDisks:g}=s,k=Number(r),b=Number(c);return(0,f.jsxs)("div",{className:pe("pdisk"),id:e,children:[(0,f.jsxs)("div",{className:pe("pdisk-header"),children:[(0,f.jsxs)("div",{className:pe("pdisk-title-wrapper"),children:[(0,f.jsx)(ae.k,{status:u}),(0,f.jsx)(ve,{label:"PDiskID",value:p,className:pe("pdisk-title-id")}),(0,f.jsx)(ve,{value:h,className:pe("pdisk-title-type")}),(0,f.jsx)(y.O,{value:k-b,capacity:k,formatValues:K.vX,colorizeProgress:!0,className:pe("pdisk-title-size")}),(0,f.jsx)(ve,{label:"VDisks",value:g.length})]}),(0,f.jsx)(J.$,{onClick:d?()=>{o(!1)}:()=>{o(!0)},view:"flat-secondary",children:(0,f.jsx)(ee.I,{direction:d?"top":"bottom"})})]}),d&&(_()(s)?(0,f.jsx)("div",{children:"No information about PDisk"}):(0,f.jsxs)("div",{children:[(0,f.jsx)(se.Q,{pDisk:s,nodeId:l,className:pe("pdisk-details"),withPDiskPageLink:!0}),(0,f.jsxs)("div",{className:pe("vdisks-container"),children:[(0,f.jsx)("div",{className:pe("vdisks-header"),children:"VDisks"}),(0,f.jsx)(H.Ay,{theme:"yandex-cloud",data:g,columns:ge({nodeId:l,pDiskId:p,selectedVdiskId:a,withDeveloperUILink:n}),settings:{...j.N3,dynamicRender:!1},rowClassName:e=>e.id===a?pe("selected-vdisk"):""})]})]}))]})}const fe=(0,p.cn)("kv-node-structure");function be({type:e,id:s}){return`${e}-${s}`}const xe=function({nodeId:e,className:s}){const a=(0,m.N4)((s=>X(s,e))),[l]=(0,m.Nt)(),{currentData:i,isFetching:n,error:d}=U.useGetNodeStructureQuery({nodeId:e},{pollingInterval:l}),r=n&&void 0===i,[{pdiskId:c,vdiskId:u}]=(0,o.useQueryParams)({pdiskId:o.StringParam,vdiskId:o.StringParam}),v=t.useRef(null),p=t.useRef(!1);return t.useEffect((()=>{if(!_()(a)&&!p.current&&v.current&&c){const s=document.getElementById(be({type:"pdisk",id:c}));let t=0;if(u){var e;const s=null===(e=a[c])||void 0===e?void 0:e.vDisks,l=null===s||void 0===s?void 0:s.find((e=>e.id===u)),i=l?document.querySelector(".data-table"):void 0,n=(null===l||void 0===l?void 0:l.order)||0;i&&(t+=i.offsetTop+40*n)}s&&(v.current.scrollTo({behavior:"smooth",top:t||s.offsetTop}),p.current=!0)}}),[a,c,u]),(0,f.jsxs)("div",{className:fe(),ref:v,children:[d?(0,f.jsx)(N.o,{error:d,className:fe("error")}):null,(0,f.jsx)("div",{className:s,children:r?(0,f.jsx)(E.a,{size:"m"}):d&&!i?null:(()=>{const s=Object.keys(a);return s.length>0?s.map((s=>(0,f.jsx)(ke,{data:a[s],id:be({type:"pdisk",id:s}),unfolded:c===s,selectedVdiskId:u,nodeId:e},s))):"There is no information about node structure."})()})]})},Ne=(0,p.cn)("node"),je="Storage";function Ie(e){var s,a;const c=t.useRef(null),u=(0,m.YQ)(),v=null!==(s=(0,n.W5)(V.Ay.node))&&void 0!==s?s:Object.create(null),{id:p,activeTab:h}=v.params,[{database:g}]=(0,o.useQueryParams)(q.Gi),[k]=(0,m.Nt)(),{currentData:b,isFetching:j,error:I}=U.useGetNodeInfoQuery({nodeId:p},{pollingInterval:k}),S=j&&void 0===b,D=b,w=(0,R.Pm)(),y=(0,R.c2)(),{activeTabVerified:z,nodeTabs:T}=t.useMemo((()=>{var e;let s=(null===D||void 0===D||null===(e=D.Roles)||void 0===e?void 0:e.find((e=>e===je)))?q.qn:q.qn.filter((e=>e.id!==q.O3));y&&(s=s.filter((e=>e.id!==q.mX)));const a=s.map((e=>({...e,title:e.name})));let t=a.find((({id:e})=>e===h));return t||(t=a[0]),{activeTabVerified:t,nodeTabs:a}}),[h,D,y]),O=(null===D||void 0===D||null===(a=D.Tenants)||void 0===a?void 0:a[0])||(null===g||void 0===g?void 0:g.toString());let C;if(D){var L;const e=!(null!==D&&void 0!==D&&null!==(L=D.Tenants)&&void 0!==L&&L[0]);C=e?"Storage":"Compute"}t.useEffect((()=>{u((0,A.g)("node",{tenantName:O,nodeRole:C,nodeId:p}))}),[u,O,p,C]);const G=()=>{switch(z.id){case q.O3:return(0,f.jsx)("div",{className:Ne("storage"),ref:c,children:(0,f.jsx)(F.z,{nodeId:p,parentRef:c,viewContext:{nodeId:null===p||void 0===p?void 0:p.toString()}})});case q.q7:return(0,f.jsx)(M.C,{nodeId:p,database:O,className:Ne("node-page-wrapper")});case q.mX:return(0,f.jsx)(xe,{className:Ne("node-page-wrapper"),nodeId:p});case q.wS:return(0,f.jsx)(P,{node:D,className:Ne("overview-wrapper")});default:return!1}};return S||!w?(0,f.jsx)(E.a,{size:"l"}):D?(0,f.jsxs)("div",{className:Ne(null,e.className),children:[(0,f.jsx)(i.mg,{titleTemplate:`%s \u2014 ${D.Host} \u2014 YDB Monitoring`,defaultTitle:`${D.Host} \u2014 YDB Monitoring`,children:(0,f.jsx)("title",{children:z.title})}),(0,f.jsx)(x,{node:D,additionalNodesProps:e.additionalNodesProps,className:Ne("header")}),I?(0,f.jsx)(N.o,{error:I,className:Ne("error")}):null,(0,f.jsxs)("div",{className:Ne("tabs"),children:[(0,f.jsx)(l.t,{size:"l",items:T,activeTab:z.id,wrapTo:({id:e},s)=>(0,f.jsx)(d.N_,{to:(0,q.vI)(p,{database:O},e),className:Ne("tab"),children:s},e),allowNotSelected:!0}),(0,f.jsx)(r.E,{})]}),(0,f.jsx)("div",{className:Ne("content"),children:G()})]}):I?(0,f.jsx)(N.o,{error:I}):(0,f.jsx)("div",{className:"error",children:"no node data"})}},76768:(e,s,a)=>{a.d(s,{C:()=>b});var t=a(44992),l=a(44508),i=a(53850),n=a(62060),d=a.n(n),o=a(21334),r=a(24600);const c=o.F.injectEndpoints({endpoints:e=>({getTabletsInfo:e.query({queryFn:async(e,{signal:s})=>{try{return{data:await window.api.viewer.getTabletsInfo(e,{signal:s})}}catch(a){return{error:a}}},providesTags:["All",{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"}),u=(0,i.Mz)((e=>e),(e=>c.endpoints.getTabletsInfo.select(e)),{argsMemoize:i.i5,argsMemoizeOptions:{equalityCheck:d()}}),v=(0,i.Mz)((e=>e),((e,s)=>u(s)),((e,s)=>s(e).data)),p=(0,i.Mz)(((e,s)=>v(e,s)),(e=>(0,r.K)(e)),((e,s)=>null!==e&&void 0!==e&&e.TabletStateInfo?s?e.TabletStateInfo.map((e=>{var a;const t=void 0===e.NodeId||null===(a=s.get(e.NodeId))||void 0===a?void 0:a.Host;return{...e,fqdn:t}})):e.TabletStateInfo:[]));var h=a(77506),m=a(90182),g=a(88616),k=a(60712);const f=(0,h.cn)("tablets");function b({nodeId:e,path:s,database:a,className:i}){const[n]=(0,m.Nt)();let d={};const o=void 0===e?void 0:String(e);void 0!==o?d={nodeId:o,database:a}:s&&(d={path:s,database:a});const{currentData:r,isFetching:u,error:v}=c.useGetTabletsInfoQuery(0===Object.keys(d).length?t.hT:d,{pollingInterval:n}),h=u&&void 0===r,b=(0,m.N4)((e=>p(e,d)));return(0,k.jsxs)("div",{className:f(null,i),children:[v?(0,k.jsx)(l.o,{error:v}):null,r||h?(0,k.jsx)(g.Q,{tablets:b,database:a,loading:h}):null]})}},76938:(e,s,a)=>{a.d(s,{A:()=>l});var t=a(59284);const l=e=>t.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),t.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 1 1-6.445 7.348.75.75 0 1 1 1.487-.194A5.001 5.001 0 1 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 0 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5",clipRule:"evenodd"}))},18677:(e,s,a)=>{a.d(s,{A:()=>l});var t=a(59284);const l=e=>t.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),t.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},74321:(e,s,a)=>{a.d(s,{S:()=>r});var t=a(59284),l=a(64222),i=a(46898);function n(e){return t.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),t.createElement("path",{d:"M4 7h9v3H4z"}))}function d(e){return t.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),t.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const o=(0,a(69220).om)("checkbox"),r=t.forwardRef((function(e,s){const{size:a="m",indeterminate:r,disabled:c=!1,content:u,children:v,title:p,style:h,className:m,qa:g}=e,{checked:k,inputProps:f}=(0,l.v)(e),b=u||v,x=t.createElement("span",{className:o("indicator")},t.createElement("span",{className:o("icon"),"aria-hidden":!0},r?t.createElement(n,{className:o("icon-svg",{type:"dash"})}):t.createElement(d,{className:o("icon-svg",{type:"tick"})})),t.createElement("input",Object.assign({},f,{className:o("control")})),t.createElement("span",{className:o("outline")}));return t.createElement(i.m,{ref:s,title:p,style:h,size:a,disabled:c,className:o({size:a,disabled:c,indeterminate:r,checked:k},m),qa:g,control:x},b)}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3738.bec1d482.chunk.js b/ydb/core/viewer/monitoring/static/js/3738.bec1d482.chunk.js new file mode 100644 index 000000000000..6733a364942f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/3738.bec1d482.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3738],{1055:e=>{function a(e){e.languages.hpkp={directive:{pattern:/\b(?:includeSubDomains|max-age|pin-sha256|preload|report-to|report-uri|strict)(?=[\s;=]|$)/i,alias:"property"},operator:/=/,punctuation:/;/}}e.exports=a,a.displayName="hpkp",a.aliases=[]},3738:(e,a,i)=>{i.d(a,{default:()=>t});var p=i(1055);const t=i.n(p)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37380.7c50d99e.chunk.js b/ydb/core/viewer/monitoring/static/js/37380.7c50d99e.chunk.js new file mode 100644 index 000000000000..a07dc4d11f95 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37380.7c50d99e.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37380],{37380:function(e,_,o){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var o=_(e),n={name:"it",weekdays:"domenica_luned\xec_marted\xec_mercoled\xec_gioved\xec_venerd\xec_sabato".split("_"),weekdaysShort:"dom_lun_mar_mer_gio_ven_sab".split("_"),weekdaysMin:"do_lu_ma_me_gi_ve_sa".split("_"),months:"gennaio_febbraio_marzo_aprile_maggio_giugno_luglio_agosto_settembre_ottobre_novembre_dicembre".split("_"),weekStart:1,monthsShort:"gen_feb_mar_apr_mag_giu_lug_ago_set_ott_nov_dic".split("_"),formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"tra %s",past:"%s fa",s:"qualche secondo",m:"un minuto",mm:"%d minuti",h:"un' ora",hh:"%d ore",d:"un giorno",dd:"%d giorni",M:"un mese",MM:"%d mesi",y:"un anno",yy:"%d anni"},ordinal:function(e){return e+"\xba"}};return o.default.locale(n,null,!0),n}(o(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37385.c32c6c83.chunk.js b/ydb/core/viewer/monitoring/static/js/37385.c32c6c83.chunk.js new file mode 100644 index 000000000000..846bb68ec688 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37385.c32c6c83.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37385],{6676:e=>{function d(e){!function(e){var d=/(?:[\w-]+|'[^'\n\r]*'|"(?:\\.|[^\\"\r\n])*")/.source;function n(e){return e.replace(/__/g,(function(){return d}))}e.languages.toml={comment:{pattern:/#.*/,greedy:!0},table:{pattern:RegExp(n(/(^[\t ]*\[\s*(?:\[\s*)?)__(?:\s*\.\s*__)*(?=\s*\])/.source),"m"),lookbehind:!0,greedy:!0,alias:"class-name"},key:{pattern:RegExp(n(/(^[\t ]*|[{,]\s*)__(?:\s*\.\s*__)*(?=\s*=)/.source),"m"),lookbehind:!0,greedy:!0,alias:"property"},string:{pattern:/"""(?:\\[\s\S]|[^\\])*?"""|'''[\s\S]*?'''|'[^'\n\r]*'|"(?:\\.|[^\\"\r\n])*"/,greedy:!0},date:[{pattern:/\b\d{4}-\d{2}-\d{2}(?:[T\s]\d{2}:\d{2}:\d{2}(?:\.\d+)?(?:Z|[+-]\d{2}:\d{2})?)?\b/i,alias:"number"},{pattern:/\b\d{2}:\d{2}:\d{2}(?:\.\d+)?\b/,alias:"number"}],number:/(?:\b0(?:x[\da-zA-Z]+(?:_[\da-zA-Z]+)*|o[0-7]+(?:_[0-7]+)*|b[10]+(?:_[10]+)*))\b|[-+]?\b\d+(?:_\d+)*(?:\.\d+(?:_\d+)*)?(?:[eE][+-]?\d+(?:_\d+)*)?\b|[-+]?\b(?:inf|nan)\b/,boolean:/\b(?:false|true)\b/,punctuation:/[.,=[\]{}]/}}(e)}e.exports=d,d.displayName="toml",d.aliases=[]},37385:(e,d,n)=>{n.d(d,{default:()=>t});var a=n(6676);const t=n.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3756.9a440b73.chunk.js b/ydb/core/viewer/monitoring/static/js/3756.9a440b73.chunk.js deleted file mode 100644 index f84955449d77..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3756.9a440b73.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3756],{93756:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"pa-in",weekdays:"\u0a10\u0a24\u0a35\u0a3e\u0a30_\u0a38\u0a4b\u0a2e\u0a35\u0a3e\u0a30_\u0a2e\u0a70\u0a17\u0a32\u0a35\u0a3e\u0a30_\u0a2c\u0a41\u0a27\u0a35\u0a3e\u0a30_\u0a35\u0a40\u0a30\u0a35\u0a3e\u0a30_\u0a38\u0a3c\u0a41\u0a71\u0a15\u0a30\u0a35\u0a3e\u0a30_\u0a38\u0a3c\u0a28\u0a40\u0a1a\u0a30\u0a35\u0a3e\u0a30".split("_"),months:"\u0a1c\u0a28\u0a35\u0a30\u0a40_\u0a2b\u0a3c\u0a30\u0a35\u0a30\u0a40_\u0a2e\u0a3e\u0a30\u0a1a_\u0a05\u0a2a\u0a4d\u0a30\u0a48\u0a32_\u0a2e\u0a08_\u0a1c\u0a42\u0a28_\u0a1c\u0a41\u0a32\u0a3e\u0a08_\u0a05\u0a17\u0a38\u0a24_\u0a38\u0a24\u0a70\u0a2c\u0a30_\u0a05\u0a15\u0a24\u0a42\u0a2c\u0a30_\u0a28\u0a35\u0a70\u0a2c\u0a30_\u0a26\u0a38\u0a70\u0a2c\u0a30".split("_"),weekdaysShort:"\u0a10\u0a24_\u0a38\u0a4b\u0a2e_\u0a2e\u0a70\u0a17\u0a32_\u0a2c\u0a41\u0a27_\u0a35\u0a40\u0a30_\u0a38\u0a3c\u0a41\u0a15\u0a30_\u0a38\u0a3c\u0a28\u0a40".split("_"),monthsShort:"\u0a1c\u0a28\u0a35\u0a30\u0a40_\u0a2b\u0a3c\u0a30\u0a35\u0a30\u0a40_\u0a2e\u0a3e\u0a30\u0a1a_\u0a05\u0a2a\u0a4d\u0a30\u0a48\u0a32_\u0a2e\u0a08_\u0a1c\u0a42\u0a28_\u0a1c\u0a41\u0a32\u0a3e\u0a08_\u0a05\u0a17\u0a38\u0a24_\u0a38\u0a24\u0a70\u0a2c\u0a30_\u0a05\u0a15\u0a24\u0a42\u0a2c\u0a30_\u0a28\u0a35\u0a70\u0a2c\u0a30_\u0a26\u0a38\u0a70\u0a2c\u0a30".split("_"),weekdaysMin:"\u0a10\u0a24_\u0a38\u0a4b\u0a2e_\u0a2e\u0a70\u0a17\u0a32_\u0a2c\u0a41\u0a27_\u0a35\u0a40\u0a30_\u0a38\u0a3c\u0a41\u0a15\u0a30_\u0a38\u0a3c\u0a28\u0a40".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm \u0a35\u0a1c\u0a47",LTS:"A h:mm:ss \u0a35\u0a1c\u0a47",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm \u0a35\u0a1c\u0a47",LLLL:"dddd, D MMMM YYYY, A h:mm \u0a35\u0a1c\u0a47"},relativeTime:{future:"%s \u0a35\u0a3f\u0a71\u0a1a",past:"%s \u0a2a\u0a3f\u0a1b\u0a32\u0a47",s:"\u0a15\u0a41\u0a1d \u0a38\u0a15\u0a3f\u0a70\u0a1f",m:"\u0a07\u0a15 \u0a2e\u0a3f\u0a70\u0a1f",mm:"%d \u0a2e\u0a3f\u0a70\u0a1f",h:"\u0a07\u0a71\u0a15 \u0a18\u0a70\u0a1f\u0a3e",hh:"%d \u0a18\u0a70\u0a1f\u0a47",d:"\u0a07\u0a71\u0a15 \u0a26\u0a3f\u0a28",dd:"%d \u0a26\u0a3f\u0a28",M:"\u0a07\u0a71\u0a15 \u0a2e\u0a39\u0a40\u0a28\u0a3e",MM:"%d \u0a2e\u0a39\u0a40\u0a28\u0a47",y:"\u0a07\u0a71\u0a15 \u0a38\u0a3e\u0a32",yy:"%d \u0a38\u0a3e\u0a32"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37579.aa311c74.chunk.js b/ydb/core/viewer/monitoring/static/js/37579.aa311c74.chunk.js new file mode 100644 index 000000000000..ff0303e5b3ef --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37579.aa311c74.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37579],{37579:function(_,e,d){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var d=e(_),M={name:"ko",weekdays:"\uc77c\uc694\uc77c_\uc6d4\uc694\uc77c_\ud654\uc694\uc77c_\uc218\uc694\uc77c_\ubaa9\uc694\uc77c_\uae08\uc694\uc77c_\ud1a0\uc694\uc77c".split("_"),weekdaysShort:"\uc77c_\uc6d4_\ud654_\uc218_\ubaa9_\uae08_\ud1a0".split("_"),weekdaysMin:"\uc77c_\uc6d4_\ud654_\uc218_\ubaa9_\uae08_\ud1a0".split("_"),months:"1\uc6d4_2\uc6d4_3\uc6d4_4\uc6d4_5\uc6d4_6\uc6d4_7\uc6d4_8\uc6d4_9\uc6d4_10\uc6d4_11\uc6d4_12\uc6d4".split("_"),monthsShort:"1\uc6d4_2\uc6d4_3\uc6d4_4\uc6d4_5\uc6d4_6\uc6d4_7\uc6d4_8\uc6d4_9\uc6d4_10\uc6d4_11\uc6d4_12\uc6d4".split("_"),ordinal:function(_){return _+"\uc77c"},formats:{LT:"A h:mm",LTS:"A h:mm:ss",L:"YYYY.MM.DD.",LL:"YYYY\ub144 MMMM D\uc77c",LLL:"YYYY\ub144 MMMM D\uc77c A h:mm",LLLL:"YYYY\ub144 MMMM D\uc77c dddd A h:mm",l:"YYYY.MM.DD.",ll:"YYYY\ub144 MMMM D\uc77c",lll:"YYYY\ub144 MMMM D\uc77c A h:mm",llll:"YYYY\ub144 MMMM D\uc77c dddd A h:mm"},meridiem:function(_){return _<12?"\uc624\uc804":"\uc624\ud6c4"},relativeTime:{future:"%s \ud6c4",past:"%s \uc804",s:"\uba87 \ucd08",m:"1\ubd84",mm:"%d\ubd84",h:"\ud55c \uc2dc\uac04",hh:"%d\uc2dc\uac04",d:"\ud558\ub8e8",dd:"%d\uc77c",M:"\ud55c \ub2ec",MM:"%d\ub2ec",y:"\uc77c \ub144",yy:"%d\ub144"}};return d.default.locale(M,null,!0),M}(d(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37605.270ebf37.chunk.js b/ydb/core/viewer/monitoring/static/js/37605.270ebf37.chunk.js new file mode 100644 index 000000000000..250b5f341426 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37605.270ebf37.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37605],{28266:e=>{function n(e){!function(e){var n=/\b(?:abstype|and|andalso|as|case|datatype|do|else|end|eqtype|exception|fn|fun|functor|handle|if|in|include|infix|infixr|let|local|nonfix|of|op|open|orelse|raise|rec|sharing|sig|signature|struct|structure|then|type|val|where|while|with|withtype)\b/i;e.languages.sml={comment:/\(\*(?:[^*(]|\*(?!\))|\((?!\*)|\(\*(?:[^*(]|\*(?!\))|\((?!\*))*\*\))*\*\)/,string:{pattern:/#?"(?:[^"\\]|\\.)*"/,greedy:!0},"class-name":[{pattern:RegExp(/((?:^|[^:]):\s*)(?:\s*(?:(?:\*|->)\s*|,\s*(?:(?=)|(?!)\s+)))*/.source.replace(//g,(function(){return/\s*(?:[*,]|->)/.source})).replace(//g,(function(){return/(?:'[\w']*||\((?:[^()]|\([^()]*\))*\)|\{(?:[^{}]|\{[^{}]*\})*\})(?:\s+)*/.source})).replace(//g,(function(){return/(?!)[a-z\d_][\w'.]*/.source})).replace(//g,(function(){return n.source})),"i"),lookbehind:!0,greedy:!0,inside:null},{pattern:/((?:^|[^\w'])(?:datatype|exception|functor|signature|structure|type)\s+)[a-z_][\w'.]*/i,lookbehind:!0}],function:{pattern:/((?:^|[^\w'])fun\s+)[a-z_][\w'.]*/i,lookbehind:!0},keyword:n,variable:{pattern:/(^|[^\w'])'[\w']*/,lookbehind:!0},number:/~?\b(?:\d+(?:\.\d+)?(?:e~?\d+)?|0x[\da-f]+)\b/i,word:{pattern:/\b0w(?:\d+|x[\da-f]+)\b/i,alias:"constant"},boolean:/\b(?:false|true)\b/i,operator:/\.\.\.|:[>=:]|=>?|->|[<>]=?|[!+\-*/^#|@~]/,punctuation:/[(){}\[\].:,;]/},e.languages.sml["class-name"][0].inside=e.languages.sml,e.languages.smlnj=e.languages.sml}(e)}e.exports=n,n.displayName="sml",n.aliases=["smlnj"]},37605:(e,n,a)=>{a.d(n,{default:()=>s});var t=a(28266);const s=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3761.dd957fd1.chunk.js b/ydb/core/viewer/monitoring/static/js/3761.dd957fd1.chunk.js deleted file mode 100644 index 8d3770f8bcbd..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3761.dd957fd1.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3761],{43761:function(e,_,s){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var s=_(e),t={name:"ca",weekdays:"Diumenge_Dilluns_Dimarts_Dimecres_Dijous_Divendres_Dissabte".split("_"),weekdaysShort:"Dg._Dl._Dt._Dc._Dj._Dv._Ds.".split("_"),weekdaysMin:"Dg_Dl_Dt_Dc_Dj_Dv_Ds".split("_"),months:"Gener_Febrer_Mar\xe7_Abril_Maig_Juny_Juliol_Agost_Setembre_Octubre_Novembre_Desembre".split("_"),monthsShort:"Gen._Febr._Mar\xe7_Abr._Maig_Juny_Jul._Ag._Set._Oct._Nov._Des.".split("_"),weekStart:1,formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM [de] YYYY",LLL:"D MMMM [de] YYYY [a les] H:mm",LLLL:"dddd D MMMM [de] YYYY [a les] H:mm",ll:"D MMM YYYY",lll:"D MMM YYYY, H:mm",llll:"ddd D MMM YYYY, H:mm"},relativeTime:{future:"d'aqu\xed %s",past:"fa %s",s:"uns segons",m:"un minut",mm:"%d minuts",h:"una hora",hh:"%d hores",d:"un dia",dd:"%d dies",M:"un mes",MM:"%d mesos",y:"un any",yy:"%d anys"},ordinal:function(e){return e+(1===e||3===e?"r":2===e?"n":4===e?"t":"\xe8")}};return s.default.locale(t,null,!0),t}(s(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37677.c7cb500e.chunk.js b/ydb/core/viewer/monitoring/static/js/37677.c7cb500e.chunk.js new file mode 100644 index 000000000000..1352dd8d3081 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37677.c7cb500e.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37677],{37677:(e,a,i)=>{i.d(a,{default:()=>n});var t=i(68266);const n=i.n(t)()},68266:e=>{function a(e){e.languages.haskell={comment:{pattern:/(^|[^-!#$%*+=?&@|~.:<>^\\\/])(?:--(?:(?=.)[^-!#$%*+=?&@|~.:<>^\\\/].*|$)|\{-[\s\S]*?-\})/m,lookbehind:!0},char:{pattern:/'(?:[^\\']|\\(?:[abfnrtv\\"'&]|\^[A-Z@[\]^_]|ACK|BEL|BS|CAN|CR|DC1|DC2|DC3|DC4|DEL|DLE|EM|ENQ|EOT|ESC|ETB|ETX|FF|FS|GS|HT|LF|NAK|NUL|RS|SI|SO|SOH|SP|STX|SUB|SYN|US|VT|\d+|o[0-7]+|x[0-9a-fA-F]+))'/,alias:"string"},string:{pattern:/"(?:[^\\"]|\\(?:\S|\s+\\))*"/,greedy:!0},keyword:/\b(?:case|class|data|deriving|do|else|if|in|infixl|infixr|instance|let|module|newtype|of|primitive|then|type|where)\b/,"import-statement":{pattern:/(^[\t ]*)import\s+(?:qualified\s+)?(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*(?:\s+as\s+(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*)?(?:\s+hiding\b)?/m,lookbehind:!0,inside:{keyword:/\b(?:as|hiding|import|qualified)\b/,punctuation:/\./}},builtin:/\b(?:abs|acos|acosh|all|and|any|appendFile|approxRational|asTypeOf|asin|asinh|atan|atan2|atanh|basicIORun|break|catch|ceiling|chr|compare|concat|concatMap|const|cos|cosh|curry|cycle|decodeFloat|denominator|digitToInt|div|divMod|drop|dropWhile|either|elem|encodeFloat|enumFrom|enumFromThen|enumFromThenTo|enumFromTo|error|even|exp|exponent|fail|filter|flip|floatDigits|floatRadix|floatRange|floor|fmap|foldl|foldl1|foldr|foldr1|fromDouble|fromEnum|fromInt|fromInteger|fromIntegral|fromRational|fst|gcd|getChar|getContents|getLine|group|head|id|inRange|index|init|intToDigit|interact|ioError|isAlpha|isAlphaNum|isAscii|isControl|isDenormalized|isDigit|isHexDigit|isIEEE|isInfinite|isLower|isNaN|isNegativeZero|isOctDigit|isPrint|isSpace|isUpper|iterate|last|lcm|length|lex|lexDigits|lexLitChar|lines|log|logBase|lookup|map|mapM|mapM_|max|maxBound|maximum|maybe|min|minBound|minimum|mod|negate|not|notElem|null|numerator|odd|or|ord|otherwise|pack|pi|pred|primExitWith|print|product|properFraction|putChar|putStr|putStrLn|quot|quotRem|range|rangeSize|read|readDec|readFile|readFloat|readHex|readIO|readInt|readList|readLitChar|readLn|readOct|readParen|readSigned|reads|readsPrec|realToFrac|recip|rem|repeat|replicate|return|reverse|round|scaleFloat|scanl|scanl1|scanr|scanr1|seq|sequence|sequence_|show|showChar|showInt|showList|showLitChar|showParen|showSigned|showString|shows|showsPrec|significand|signum|sin|sinh|snd|sort|span|splitAt|sqrt|subtract|succ|sum|tail|take|takeWhile|tan|tanh|threadToIOResult|toEnum|toInt|toInteger|toLower|toRational|toUpper|truncate|uncurry|undefined|unlines|until|unwords|unzip|unzip3|userError|words|writeFile|zip|zip3|zipWith|zipWith3)\b/,number:/\b(?:\d+(?:\.\d+)?(?:e[+-]?\d+)?|0o[0-7]+|0x[0-9a-f]+)\b/i,operator:[{pattern:/`(?:[A-Z][\w']*\.)*[_a-z][\w']*`/,greedy:!0},{pattern:/(\s)\.(?=\s)/,lookbehind:!0},/[-!#$%*+=?&@|~:<>^\\\/][-!#$%*+=?&@|~.:<>^\\\/]*|\.[-!#$%*+=?&@|~.:<>^\\\/]+/],hvariable:{pattern:/\b(?:[A-Z][\w']*\.)*[_a-z][\w']*/,inside:{punctuation:/\./}},constant:{pattern:/\b(?:[A-Z][\w']*\.)*[A-Z][\w']*/,inside:{punctuation:/\./}},punctuation:/[{}[\];(),.:]/},e.languages.hs=e.languages.haskell}e.exports=a,a.displayName="haskell",a.aliases=["hs"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3769.860e8d58.chunk.js b/ydb/core/viewer/monitoring/static/js/3769.860e8d58.chunk.js deleted file mode 100644 index db616d2df86d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3769.860e8d58.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3769],{63769:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-sg",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37747.ab1590d9.chunk.js b/ydb/core/viewer/monitoring/static/js/37747.ab1590d9.chunk.js new file mode 100644 index 000000000000..decf4c794c71 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37747.ab1590d9.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37747],{37747:(e,n,g)=>{g.d(n,{default:()=>i});var a=g(60586);const i=g.n(a)()},60586:e=>{function n(e){!function(e){e.languages.ignore={comment:/^#.*/m,entry:{pattern:/\S(?:.*(?:(?:\\ )|\S))?/,alias:"string",inside:{operator:/^!|\*\*?|\?/,regex:{pattern:/(^|[^\\])\[[^\[\]]*\]/,lookbehind:!0},punctuation:/\//}}},e.languages.gitignore=e.languages.ignore,e.languages.hgignore=e.languages.ignore,e.languages.npmignore=e.languages.ignore}(e)}e.exports=n,n.displayName="ignore",n.aliases=["gitignore","hgignore","npmignore"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3779.9f31a4d0.chunk.js b/ydb/core/viewer/monitoring/static/js/3779.9f31a4d0.chunk.js deleted file mode 100644 index aa68cb4127b4..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3779.9f31a4d0.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3779],{90053:(e,s,t)=>{t.d(s,{E:()=>h});var r=t(8873),a=t(84476),l=t(24555),n=t(21334),o=t(77506),i=t(90182),c=t(48372);const d=JSON.parse('{"None":"None","15 sec":"15 sec","1 min":"1 min","2 min":"2 min","5 min":"5 min","Refresh":"Refresh"}'),u=(0,c.g4)("ydb-diagnostics-autorefresh-control",{en:d});var v=t(60712);const m=(0,o.cn)("auto-refresh-control");function h({className:e}){const s=(0,i.YQ)(),[t,o]=(0,i.Nt)();return(0,v.jsxs)("div",{className:m(null,e),children:[(0,v.jsx)(a.$,{view:"flat-secondary",onClick:()=>{s(n.F.util.invalidateTags(["All"]))},extraProps:{"aria-label":u("Refresh")},children:(0,v.jsx)(a.$.Icon,{children:(0,v.jsx)(r.A,{})})}),(0,v.jsxs)(l.l,{value:[String(t)],onUpdate:e=>{o(Number(e))},width:85,qa:"ydb-autorefresh-select",children:[(0,v.jsx)(l.l.Option,{value:"0",children:u("None")}),(0,v.jsx)(l.l.Option,{value:"15000",children:u("15 sec")}),(0,v.jsx)(l.l.Option,{value:"60000",children:u("1 min")}),(0,v.jsx)(l.l.Option,{value:"120000",children:u("2 min")}),(0,v.jsx)(l.l.Option,{value:"300000",children:u("5 min")})]})]})}},52248:(e,s,t)=>{t.d(s,{a:()=>r.a});var r=t(47334)},15132:(e,s,t)=>{t.d(s,{O:()=>v});var r=t(38501),a=t(77506),l=t(56839),n=t(35736),o=t(41650),i=t(60712);const c=(0,a.cn)("progress-viewer"),d=e=>(0,l.ZV)((0,l.CR)(Number(e),2)),u=(e,s)=>[d(e),d(s)];function v({value:e,capacity:s,formatValues:t=u,percents:a,className:l,size:d="xs",colorizeProgress:v,inverseColorize:m,warningThreshold:h,dangerThreshold:N,hideCapacity:g}){const p=(0,r.D)();let S=Math.round(parseFloat(String(e))/parseFloat(String(s))*100)||0;S=S>100?100:S;let f=e,b=s,x="/";a?(f=S+"%",b="",x=""):t&&([f,b]=t(Number(e),Number(s)));const E=(0,n.w)({fillWidth:S,warningThreshold:h,dangerThreshold:N,colorizeProgress:v,inverseColorize:m});v&&!(0,o.kf)(s)&&(S=100);const j={width:S+"%"};return(0,o.kf)(e)?(0,i.jsxs)("div",{className:c({size:d,theme:p,status:E},l),children:[(0,i.jsx)("div",{className:c("line"),style:j}),(0,i.jsx)("span",{className:c("text"),children:(0,o.kf)(s)&&!g?`${f} ${x} ${b}`:f})]}):(0,i.jsx)("div",{className:`${c({size:d})} ${l} error`,children:"no data"})}},17594:(e,s,t)=>{t.d(s,{l:()=>c});var r=t(69024),a=t(4557),l=t(77506),n=t(16819),o=t(60712);const i=(0,l.cn)("ydb-resizeable-data-table");function c({columnsWidthLSKey:e,columns:s,settings:t,wrapperClassName:l,...c}){const[d,u]=(0,n.a)(e),v=(0,r.j)(s,d),m={...t,defaultResizeable:!0};return(0,o.jsx)("div",{className:i(null,l),children:(0,o.jsx)(a.Ay,{theme:"yandex-cloud",columns:v,onResize:u,settings:m,...c})})}},41775:(e,s,t)=>{t.d(s,{v:()=>i});var r=t(59284),a=t(28664),l=t(77506),n=t(60712);const o=(0,l.cn)("ydb-search"),i=({onChange:e,value:s="",width:t,className:l,debounce:i=200,placeholder:c})=>{const[d,u]=r.useState(s),v=r.useRef();r.useEffect((()=>{u((e=>e!==s?s:e))}),[s]);return(0,n.jsx)(a.k,{hasClear:!0,autoFocus:!0,style:{width:t},className:o(null,l),placeholder:c,value:d,onUpdate:s=>{u(s),window.clearTimeout(v.current),v.current=window.setTimeout((()=>{null===e||void 0===e||e(s)}),i)}})}},95963:(e,s,t)=>{t.d(s,{v:()=>r.v});var r=t(41775)},48288:(e,s,t)=>{t.r(s),t.d(s,{Clusters:()=>se});var r=t(59284),a=t(4557),l=t(24555),n=t(69775),o=t(61750),i=t(90053),c=t(44508),d=t(52248),u=t(17594),v=t(95963),m=t(39567),h=t(23536),N=t.n(h);const g=e=>e.clusters.clusterName,p=e=>e.clusters.status,S=e=>e.clusters.service,f=e=>e.clusters.version,b=(e,s)=>0===s.length||e.status&&s.includes(e.status),x=(e,s)=>0===s.length||e.service&&s.includes(e.service),E=(e,s)=>0===s.length||s.some((s=>{var t,r;return null===(t=e.cluster)||void 0===t||null===(r=t.Versions)||void 0===r?void 0:r.some((e=>e.startsWith(s)))})),j=(e,s="")=>{var t;if(!s)return!0;const r=s.toLowerCase(),a=r.split(" "),l=(null===(t=e.title)||void 0===t?void 0:t.toLowerCase().match(/[^\d\s]+|\d+|[^-\s]+|[^_\s]+/g))||[],n=a.every((s=>{const t=N()(s),r=new RegExp(`^${t}|[\\s\\-_]${t}`,"i");return e.title&&r.test(e.title)||l.some((e=>e.startsWith(s)))})),o=e.preparedVersions.some((e=>e.version.includes(r))),i=Boolean(e.hosts&&e.hosts[r]);return n||o||i};var T=t(76086),O=t(90182),C=t(43951),w=t(38596),A=t(15132),_=t(56839),y=t(48372);const R=JSON.parse('{"controls_status-select-label":"Status:","controls_service-select-label":"Service:","controls_version-select-label":"Version:","controls_search-placeholder":"Cluster name, version, host","controls_select-placeholder":"All","statistics_clusters":"Clusters","statistics_hosts":"Hosts","statistics_tenants":"Tenants","statistics_nodes":"Nodes","statistics_load":"Load","statistics_storage":"Storage","tooltip_no-cluster-data":"No cluster data","page_title":"Clusters"}'),I=JSON.parse('{"controls_status-select-label":"\u0421\u0442\u0430\u0442\u0443\u0441:","controls_service-select-label":"\u0421\u0435\u0440\u0432\u0438\u0441:","controls_version-select-label":"\u0412\u0435\u0440\u0441\u0438\u044f:","controls_search-placeholder":"\u0418\u043c\u044f \u043a\u043b\u0430\u0441\u0442\u0435\u0440\u0430, \u0432\u0435\u0440\u0441\u0438\u044f \u0438\u043b\u0438 \u0445\u043e\u0441\u0442","controls_select-placeholder":"\u0412\u0441\u0435","statistics_clusters":"\u041a\u043b\u0430\u0441\u0442\u0435\u0440\u044b","statistics_hosts":"\u0425\u043e\u0441\u0442\u044b","statistics_tenants":"\u0411\u0430\u0437\u044b \u0434\u0430\u043d\u043d\u044b\u0445","statistics_nodes":"\u0423\u0437\u043b\u044b","statistics_load":"\u041d\u0430\u0433\u0440\u0443\u0437\u043a\u0430","statistics_storage":"\u0425\u0440\u0430\u043d\u0438\u043b\u0438\u0449\u0435","tooltip_no-cluster-data":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445 \u043a\u043b\u0430\u0441\u0442\u0435\u0440\u0430","page_title":"\u041a\u043b\u0430\u0441\u0442\u0435\u0440\u044b"}'),D=(0,y.g4)("ydb-clusters-page",{ru:I,en:R});var z=t(77506);const L=(0,z.cn)("clusters");var k=t(60712);const V=({count:e,stats:s})=>{const{NodesTotal:t,NodesAlive:r,Hosts:a,Tenants:l,LoadAverage:n,NumberOfCpus:o,StorageUsed:i,StorageTotal:c}=s;return(0,k.jsxs)("div",{className:L("aggregation"),children:[(0,k.jsxs)("div",{className:L("aggregation-value-container"),children:[(0,k.jsx)("span",{className:L("aggregation-label"),children:D("statistics_clusters")}),e]}),(0,k.jsxs)("div",{className:L("aggregation-value-container"),children:[(0,k.jsx)("span",{className:L("aggregation-label"),children:D("statistics_hosts")}),a]}),(0,k.jsxs)("div",{className:L("aggregation-value-container"),children:[(0,k.jsx)("span",{className:L("aggregation-label"),children:D("statistics_tenants")}),l]}),(0,k.jsxs)("div",{className:L("aggregation-value-container"),children:[(0,k.jsx)("span",{className:L("aggregation-label"),children:D("statistics_nodes")}),(0,k.jsx)(A.O,{size:"ns",value:r,capacity:t,colorizeProgress:!0,inverseColorize:!0})]}),(0,k.jsxs)("div",{className:L("aggregation-value-container"),children:[(0,k.jsx)("span",{className:L("aggregation-label"),children:D("statistics_load")}),(0,k.jsx)(A.O,{size:"ns",value:n,capacity:o,colorizeProgress:!0})]}),(0,k.jsxs)("div",{className:L("aggregation-value-container"),children:[(0,k.jsx)("span",{className:L("aggregation-label"),children:D("statistics_storage")}),(0,k.jsx)(A.O,{size:"ns",value:i,capacity:c,formatValues:_.j9,colorizeProgress:!0})]})]})};var U=t(6170),G=t(67884),W=t(18143),P=t(96873),$=t(34271);const H=(0,z.cn)("kv-user");function M({login:e,className:s}){const t=(0,$.x)("StaffCard");return(0,k.jsx)("div",{className:H(null,s),children:(0,k.jsx)(t,{login:e,children:(0,k.jsx)("div",{className:H("name"),children:e})})})}var B=t(31684),F=t(69446),q=t(87842);const K="selectedColumns",J={TITLE:"title",VERSIONS:"versions",DC:"dc",SERVICE:"service",STATUS:"status",NODES:"nodes",LOAD:"load",STORAGE:"storage",HOSTS:"hosts",TENANTS:"tenants",OWNER:"owner",DESCRIPTION:"description",BALANCER:"balancer"},Q=[J.TITLE,J.VERSIONS,J.SERVICE,J.STATUS,J.NODES,J.LOAD,J.STORAGE,J.HOSTS,J.TENANTS,J.OWNER,J.BALANCER],X={[J.TITLE]:"Cluster",[J.VERSIONS]:"Versions",[J.DC]:"DC",[J.SERVICE]:"Service",[J.STATUS]:"Status",[J.NODES]:"Nodes",[J.LOAD]:"Load",[J.STORAGE]:"Storage",[J.HOSTS]:"Hosts",[J.TENANTS]:"Tenants",[J.OWNER]:"Owner",[J.DESCRIPTION]:"Description",[J.BALANCER]:"Balancer"},Y="clustersTableColumnsWidth",Z=(0,k.jsx)("span",{className:L("empty-cell"),children:"\u2014"}),ee=[{name:J.TITLE,header:X[J.TITLE],width:230,render:({row:e})=>{var s,t;const{balancer:r,name:a,use_embedded_ui:l}=e,n=r&&(0,F.PG)(r),o=l&&n?(0,B.t1)(n):(0,q.a)(void 0,{backend:n,clusterName:a}),i=null===(s=e.cluster)||void 0===s?void 0:s.Overall;return(0,k.jsxs)("div",{className:L("cluster"),children:[i?(0,k.jsx)(G.N,{href:o,children:(0,k.jsx)("div",{className:L("cluster-status",{type:i&&i.toLowerCase()})})}):(0,k.jsx)("div",{className:L("cluster-status"),children:(0,k.jsx)(U.B,{content:(0,k.jsx)("span",{className:L("tooltip-content"),children:(null===(t=e.cluster)||void 0===t?void 0:t.error)||D("tooltip_no-cluster-data")}),offset:{left:0}})}),(0,k.jsx)("div",{className:L("cluster-name"),children:(0,k.jsx)(G.N,{href:o,children:e.title})})]})},defaultOrder:a.Ay.ASCENDING},{name:J.VERSIONS,header:X[J.VERSIONS],width:300,defaultOrder:a.Ay.DESCENDING,sortAccessor:({preparedVersions:e})=>e.map((e=>e.version.replace(/^[0-9]\+\./g,""))).sort(((e,s)=>e.localeCompare(s)))[0]||void 0,render:({row:e})=>{const{preparedVersions:s,versions:t=[],balancer:a,name:l}=e;if(!t.length||t.some((e=>!e.version)))return Z;const n=t.reduce(((e,s)=>e+s.count),0),o=t.map((e=>{var t;return{value:e.count/n*100,color:null===(t=s.find((s=>s.version===e.version)))||void 0===t?void 0:t.color}})),i=a&&(0,F.PG)(a);return s.length>0&&(0,k.jsx)(G.N,{className:L("cluster-versions"),href:(0,q.a)(q.Bi.versions,{backend:i,clusterName:l}),children:(0,k.jsxs)(r.Fragment,{children:[s.map(((e,s)=>(0,k.jsx)("div",{className:L("cluster-version"),style:{color:e.color},title:e.version,children:e.version},s))),(0,k.jsx)(W.k,{size:"s",value:100,stack:o})]})})}},{name:J.DC,header:X[J.DC],width:120,sortable:!1,render:({row:e})=>{const s=e.cluster&&e.cluster.DataCenters||[];return(0,k.jsx)("div",{className:L("cluster-dc"),children:s.join(", ")||Z})}},{name:J.SERVICE,header:X[J.SERVICE],width:100,sortable:!0},{name:J.STATUS,header:X[J.STATUS],width:150,sortable:!0},{name:J.NODES,header:X[J.NODES],resizeMinWidth:170,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e={}})=>{const{NodesTotal:s=0}=e;return s},render:({row:e})=>{const{NodesAlive:s=0,NodesTotal:t=0,Overall:r}=e.cluster||{};return r?(0,k.jsx)(A.O,{value:s,capacity:t}):Z}},{name:J.LOAD,header:X[J.LOAD],resizeMinWidth:170,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>null===e||void 0===e?void 0:e.NumberOfCpus,render:({row:e})=>{const{LoadAverage:s=0,NumberOfCpus:t=0,Overall:r}=e.cluster||{};return r?(0,k.jsx)(A.O,{value:s,capacity:t}):Z}},{name:J.STORAGE,header:X[J.STORAGE],resizeMinWidth:170,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>Number(null===e||void 0===e?void 0:e.StorageTotal),render:({row:e})=>{const{StorageUsed:s=0,StorageTotal:t=0,Overall:r}=e.cluster||{};return r?(0,k.jsx)(A.O,{value:s,capacity:t,formatValues:_.ki}):Z}},{name:J.HOSTS,header:X[J.HOSTS],width:80,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>Number(null===e||void 0===e?void 0:e.Hosts)||0,render:({row:e})=>{var s;return Number(null===(s=e.cluster)||void 0===s?void 0:s.Hosts)||Z}},{name:J.TENANTS,header:X[J.TENANTS],width:80,defaultOrder:a.Ay.DESCENDING,sortAccessor:({cluster:e})=>Number(null===e||void 0===e?void 0:e.Tenants)||0,render:({row:e})=>{var s;return Number(null===(s=e.cluster)||void 0===s?void 0:s.Tenants)||Z}},{name:J.OWNER,header:X[J.OWNER],sortable:!1,width:120,render:({row:e})=>{var s;const t=null===(s=e.owner)||void 0===s?void 0:s.split(", ");return null!==t&&void 0!==t&&t.length?t.map((e=>(0,k.jsx)(M,{login:e},e))):Z}},{name:J.DESCRIPTION,header:X[J.DESCRIPTION],sortable:!1,width:150,render:({row:e})=>e.description?(0,k.jsx)("div",{className:L("description"),children:e.description}):Z},{name:J.BALANCER,header:X[J.BALANCER],sortable:!1,width:290,render:({row:e})=>{if(!e.balancer)return Z;const s=(0,F.Zd)(e.balancer);return(0,k.jsxs)("div",{className:L("balancer-cell"),children:[(0,k.jsx)("div",{className:L("balancer-text"),children:s}),(0,k.jsx)(P.b,{size:"s",text:s,className:L("balancer-icon")})]})}}];function se(){const[e]=(0,O.Nt)(),s=m.ub.useGetClustersListQuery(void 0,{pollingInterval:e}),t=(0,O.YQ)(),h=(0,O.N4)(g),N=(0,O.N4)(p),A=(0,O.N4)(S),_=(0,O.N4)(f),{columnsToShow:y,columnsToSelect:R,setColumns:I}=(0,C.K)(ee,K,X,Q,[J.TITLE]),z=s.data,{servicesToSelect:U,versions:G}=r.useMemo((()=>{const e=new Set,s=new Set;return(null!==z&&void 0!==z?z:[]).forEach((t=>{var r,a;t.service&&e.add(t.service),null===(r=t.cluster)||void 0===r||null===(a=r.Versions)||void 0===a||a.forEach((e=>{s.add((0,w.U)(e))}))})),{servicesToSelect:Array.from(e).map((e=>({value:e,content:e}))),versions:Array.from(s).map((e=>({value:e,content:e})))}}),[z]),W=r.useMemo((()=>function(e,s){return e.filter((e=>b(e,s.status)&&x(e,s.service)&&E(e,s.version)&&j(e,s.clusterName)))}(null!==z&&void 0!==z?z:[],{clusterName:h,status:N,service:A,version:_})),[h,z,A,N,_]),P=r.useMemo((()=>function(e){let s=0,t=0,r=0,a=0,l=0,n=0,o=0;const i=new Set;return e.filter((({cluster:e})=>!(null!==e&&void 0!==e&&e.error))).forEach((({cluster:e,hosts:c={}})=>{s+=(null===e||void 0===e?void 0:e.NodesTotal)||0,t+=(null===e||void 0===e?void 0:e.NodesAlive)||0,Object.keys(c).forEach((e=>i.add(e))),o+=Number(null===e||void 0===e?void 0:e.Tenants)||0,r+=Number(null===e||void 0===e?void 0:e.LoadAverage)||0,a+=(null===e||void 0===e?void 0:e.NumberOfCpus)||0,l+=null!==e&&void 0!==e&&e.StorageUsed?Math.floor(parseInt(e.StorageUsed,10)):0,n+=null!==e&&void 0!==e&&e.StorageTotal?Math.floor(parseInt(e.StorageTotal,10)):0})),{NodesTotal:s,NodesAlive:t,Hosts:i.size,Tenants:o,LoadAverage:r,NumberOfCpus:a,StorageUsed:l,StorageTotal:n}}(W)),[W]),$=r.useMemo((()=>Array.from(new Set((null!==z&&void 0!==z?z:[]).map((e=>e.status)).filter(Boolean))).sort().map((e=>({value:e,content:e})))),[z]);return(0,k.jsxs)("div",{className:L(),children:[(0,k.jsx)(o.mg,{children:(0,k.jsx)("title",{children:D("page_title")})}),(0,k.jsx)(V,{stats:P,count:W.length}),(0,k.jsxs)("div",{className:L("controls"),children:[(0,k.jsx)("div",{className:L("control",{wide:!0}),children:(0,k.jsx)(v.v,{placeholder:D("controls_search-placeholder"),onChange:e=>{t((0,m.Fe)({clusterName:e}))},value:h})}),(0,k.jsx)("div",{className:L("control"),children:(0,k.jsx)(l.l,{multiple:!0,filterable:!0,hasClear:!0,placeholder:D("controls_select-placeholder"),label:D("controls_status-select-label"),value:N,options:$,onUpdate:e=>{t((0,m.Fe)({status:e}))},width:"max"})}),(0,k.jsx)("div",{className:L("control"),children:(0,k.jsx)(l.l,{multiple:!0,filterable:!0,hasClear:!0,placeholder:D("controls_select-placeholder"),label:D("controls_service-select-label"),value:A,options:U,onUpdate:e=>{t((0,m.Fe)({service:e}))},width:"max"})}),(0,k.jsx)("div",{className:L("control"),children:(0,k.jsx)(l.l,{multiple:!0,filterable:!0,hasClear:!0,placeholder:D("controls_select-placeholder"),label:D("controls_version-select-label"),value:_,options:G,onUpdate:e=>{t((0,m.Fe)({version:e}))},width:"max"})}),(0,k.jsx)("div",{className:L("control"),children:(0,k.jsx)(n.O,{popupWidth:242,items:R,showStatus:!0,onUpdate:I,sortable:!1},"TableColumnSetup")}),(0,k.jsx)(i.E,{className:L("autorefresh")})]}),s.isError?(0,k.jsx)(c.o,{error:s.error,className:L("error")}):null,s.isLoading?(0,k.jsx)(d.a,{size:"l"}):null,s.fulfilledTimeStamp?(0,k.jsx)("div",{className:L("table-wrapper"),children:(0,k.jsx)("div",{className:L("table-content"),children:(0,k.jsx)(u.l,{columnsWidthLSKey:Y,wrapperClassName:L("table"),data:W,columns:y,settings:{...T.N3,dynamicRender:!1},initialSortOrder:{columnId:J.TITLE,order:a.Ay.ASCENDING}})})}):null]})}},43951:(e,s,t)=>{t.d(s,{K:()=>l});var r=t(59284),a=t(59001);const l=(e,s,t,l,n)=>{const[o,i]=r.useState((()=>a.f.readUserSettingsValue(s,l)));return{columnsToShow:r.useMemo((()=>e.filter((e=>{const s=e.name,t=o.includes(s),r=null===n||void 0===n?void 0:n.includes(s);return t||r}))),[e,n,o]),columnsToSelect:r.useMemo((()=>e.map((e=>e.name)).map((e=>{const s=null===n||void 0===n?void 0:n.includes(e),r=o.includes(e);return{id:e,title:t[e],selected:s||r,required:s,sticky:s?"start":void 0}}))),[e,t,n,o]),setColumns:r.useCallback((e=>{const t=e.filter((e=>e.selected)).map((e=>e.id));a.f.setUserSettingsValue(s,t),i(t)}),[s])}}},16819:(e,s,t)=>{t.d(s,{a:()=>n});var r=t(59284),a=t(69024),l=t(59001);const n=e=>{const s=r.useCallback((()=>e?l.f.readUserSettingsValue(e,{}):{}),[e]),t=r.useCallback((s=>{e&&l.f.setUserSettingsValue(e,s)}),[e]);return(0,a.a)({saveSizes:t,getSizes:s})}},35736:(e,s,t)=>{t.d(s,{w:()=>a});var r=t(76086);function a({inverseColorize:e,warningThreshold:s=r.Hh,dangerThreshold:t=r.Ed,colorizeProgress:a,fillWidth:l}){let n=e?"danger":"good";return a&&(l>s&&l<=t?n="warning":l>t&&(n=e?"good":"danger")),n}},6170:(e,s,t)=>{t.d(s,{B:()=>c});var r=t(59284),a=t(73633),l=t(84375),n=t(99991);const o=(0,t(98192).om)("help-popover"),i=16;function c(e){var s;return r.createElement(l.A,Object.assign({},e,{className:o(null,e.className)}),r.createElement("button",Object.assign({ref:e.buttonRef,type:"button"},e.buttonProps,{className:o("button",null===(s=e.buttonProps)||void 0===s?void 0:s.className)}),r.createElement(n.I,{data:a.A,size:i})))}},98192:(e,s,t)=>{t.d(s,{CU:()=>a,om:()=>l});var r=t(82435);const a="gc-",l=((0,r.withNaming)({e:"__",m:"_",v:"_"}),(0,r.withNaming)({n:a,e:"__",m:"_",v:"_"}))},18143:(e,s,t)=>{t.d(s,{k:()=>u});var r=t(59284);const a=(0,t(69220).om)("progress");function l(e){const{text:s,offset:t=0}=e;return s?r.createElement("div",{className:a("text-inner"),style:{transform:`translateX(calc(var(--g-flow-direction) * ${-t}%))`}},s):null}function n({item:e}){const{value:s,color:t,className:l,theme:n,title:o,content:i,loading:c}=e,d={loading:c};return"undefined"===typeof t&&(d.theme=n||"default"),Number.isFinite(s)?r.createElement("div",{className:a("item",d,l),style:{width:`${s}%`,backgroundColor:t},title:o},i):null}function o(e){return e<100?e-100:0}function i(e){const{theme:s,colorStops:t,colorStopsValue:r,value:a}=e;if(t){const e=t.find(((e,s)=>{const l="number"===typeof r?r:a,n=s>1?t[s-1].stop:0,o=s=n&&l<=o}));return e?e.theme:s}return s}function c(e){const{stack:s,stackClassName:t,value:i,text:c}=e,d=o(i||function(e){return e.reduce(((e,{value:s})=>e+s),0)}(s));return r.createElement("div",{className:a("stack",t),style:{transform:`translateX(calc(var(--g-flow-direction) * ${d}%))`}},r.createElement("div",{className:a("item"),style:{width:-d+"%"}}),s.map(((e,s)=>r.createElement(n,{key:s,item:e}))),r.createElement(l,{offset:d,text:c}))}function d(e){const{value:s,loading:t,text:n}=e,c=o(s);return Number.isFinite(s)?r.createElement("div",{className:a("item",{theme:i(e),loading:t}),style:{transform:`translateX(calc(var(--g-flow-direction) * ${c}%))`}},r.createElement(l,{offset:c,text:n})):null}const u=r.forwardRef((function(e,s){const{text:t="",theme:l="default",size:n="m",loading:o=!1,className:i,qa:u}=e,v=Object.assign(Object.assign({},e),{text:t,theme:l,size:n,loading:o});return r.createElement("div",{ref:s,className:a({size:n},i),"data-qa":u},r.createElement("div",{className:a("text")},t),function(e){return void 0!==e.stack}(v)?r.createElement(c,Object.assign({},v)):r.createElement(d,Object.assign({},v)))}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/37963.55ad78e4.chunk.js b/ydb/core/viewer/monitoring/static/js/37963.55ad78e4.chunk.js new file mode 100644 index 000000000000..6b216f3c824a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/37963.55ad78e4.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[37963],{37963:(e,n,r)=>{r.d(n,{default:()=>i});var t=r(69084);const i=r.n(t)()},69084:e=>{function n(e){e.languages.verilog={comment:{pattern:/\/\/.*|\/\*[\s\S]*?\*\//,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"kernel-function":{pattern:/\B\$\w+\b/,alias:"property"},constant:/\B`\w+\b/,function:/\b\w+(?=\()/,keyword:/\b(?:alias|and|assert|assign|assume|automatic|before|begin|bind|bins|binsof|bit|break|buf|bufif0|bufif1|byte|case|casex|casez|cell|chandle|class|clocking|cmos|config|const|constraint|context|continue|cover|covergroup|coverpoint|cross|deassign|default|defparam|design|disable|dist|do|edge|else|end|endcase|endclass|endclocking|endconfig|endfunction|endgenerate|endgroup|endinterface|endmodule|endpackage|endprimitive|endprogram|endproperty|endsequence|endspecify|endtable|endtask|enum|event|expect|export|extends|extern|final|first_match|for|force|foreach|forever|fork|forkjoin|function|generate|genvar|highz0|highz1|if|iff|ifnone|ignore_bins|illegal_bins|import|incdir|include|initial|inout|input|inside|instance|int|integer|interface|intersect|join|join_any|join_none|large|liblist|library|local|localparam|logic|longint|macromodule|matches|medium|modport|module|nand|negedge|new|nmos|nor|noshowcancelled|not|notif0|notif1|null|or|output|package|packed|parameter|pmos|posedge|primitive|priority|program|property|protected|pull0|pull1|pulldown|pullup|pulsestyle_ondetect|pulsestyle_onevent|pure|rand|randc|randcase|randsequence|rcmos|real|realtime|ref|reg|release|repeat|return|rnmos|rpmos|rtran|rtranif0|rtranif1|scalared|sequence|shortint|shortreal|showcancelled|signed|small|solve|specify|specparam|static|string|strong0|strong1|struct|super|supply0|supply1|table|tagged|task|this|throughout|time|timeprecision|timeunit|tran|tranif0|tranif1|tri|tri0|tri1|triand|trior|trireg|type|typedef|union|unique|unsigned|use|uwire|var|vectored|virtual|void|wait|wait_order|wand|weak0|weak1|while|wildcard|wire|with|within|wor|xnor|xor)\b/,important:/\b(?:always|always_comb|always_ff|always_latch)\b(?: *@)?/,number:/\B##?\d+|(?:\b\d+)?'[odbh] ?[\da-fzx_?]+|\b(?:\d*[._])?\d+(?:e[-+]?\d+)?/i,operator:/[-+{}^~%*\/?=!<>&|]+/,punctuation:/[[\];(),.:]/}}e.exports=n,n.displayName="verilog",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/38103.a27aa378.chunk.js b/ydb/core/viewer/monitoring/static/js/38103.a27aa378.chunk.js new file mode 100644 index 000000000000..998b126243ae --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/38103.a27aa378.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[38103],{38103:function(e,t,r){e.exports=function(e){"use strict";function t(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var r=t(e),a={words:{m:["\u0458\u0435\u0434\u0430\u043d \u043c\u0438\u043d\u0443\u0442","\u0458\u0435\u0434\u043d\u043e\u0433 \u043c\u0438\u043d\u0443\u0442\u0430"],mm:["%d \u043c\u0438\u043d\u0443\u0442","%d \u043c\u0438\u043d\u0443\u0442\u0430","%d \u043c\u0438\u043d\u0443\u0442\u0430"],h:["\u0458\u0435\u0434\u0430\u043d \u0441\u0430\u0442","\u0458\u0435\u0434\u043d\u043e\u0433 \u0441\u0430\u0442\u0430"],hh:["%d \u0441\u0430\u0442","%d \u0441\u0430\u0442\u0430","%d \u0441\u0430\u0442\u0438"],d:["\u0458\u0435\u0434\u0430\u043d \u0434\u0430\u043d","\u0458\u0435\u0434\u043d\u043e\u0433 \u0434\u0430\u043d\u0430"],dd:["%d \u0434\u0430\u043d","%d \u0434\u0430\u043d\u0430","%d \u0434\u0430\u043d\u0430"],M:["\u0458\u0435\u0434\u0430\u043d \u043c\u0435\u0441\u0435\u0446","\u0458\u0435\u0434\u043d\u043e\u0433 \u043c\u0435\u0441\u0435\u0446\u0430"],MM:["%d \u043c\u0435\u0441\u0435\u0446","%d \u043c\u0435\u0441\u0435\u0446\u0430","%d \u043c\u0435\u0441\u0435\u0446\u0438"],y:["\u0458\u0435\u0434\u043d\u0443 \u0433\u043e\u0434\u0438\u043d\u0443","\u0458\u0435\u0434\u043d\u0435 \u0433\u043e\u0434\u0438\u043d\u0435"],yy:["%d \u0433\u043e\u0434\u0438\u043d\u0443","%d \u0433\u043e\u0434\u0438\u043d\u0435","%d \u0433\u043e\u0434\u0438\u043d\u0430"]},correctGrammarCase:function(e,t){return e%10>=1&&e%10<=4&&(e%100<10||e%100>=20)?e%10==1?t[0]:t[1]:t[2]},relativeTimeFormatter:function(e,t,r,_){var m=a.words[r];if(1===r.length)return"y"===r&&t?"\u0458\u0435\u0434\u043d\u0430 \u0433\u043e\u0434\u0438\u043d\u0430":_||t?m[0]:m[1];var d=a.correctGrammarCase(e,m);return"yy"===r&&t&&"%d \u0433\u043e\u0434\u0438\u043d\u0443"===d?e+" \u0433\u043e\u0434\u0438\u043d\u0430":d.replace("%d",e)}},_={name:"sr-cyrl",weekdays:"\u041d\u0435\u0434\u0435\u0459\u0430_\u041f\u043e\u043d\u0435\u0434\u0435\u0459\u0430\u043a_\u0423\u0442\u043e\u0440\u0430\u043a_\u0421\u0440\u0435\u0434\u0430_\u0427\u0435\u0442\u0432\u0440\u0442\u0430\u043a_\u041f\u0435\u0442\u0430\u043a_\u0421\u0443\u0431\u043e\u0442\u0430".split("_"),weekdaysShort:"\u041d\u0435\u0434._\u041f\u043e\u043d._\u0423\u0442\u043e._\u0421\u0440\u0435._\u0427\u0435\u0442._\u041f\u0435\u0442._\u0421\u0443\u0431.".split("_"),weekdaysMin:"\u043d\u0435_\u043f\u043e_\u0443\u0442_\u0441\u0440_\u0447\u0435_\u043f\u0435_\u0441\u0443".split("_"),months:"\u0408\u0430\u043d\u0443\u0430\u0440_\u0424\u0435\u0431\u0440\u0443\u0430\u0440_\u041c\u0430\u0440\u0442_\u0410\u043f\u0440\u0438\u043b_\u041c\u0430\u0458_\u0408\u0443\u043d_\u0408\u0443\u043b_\u0410\u0432\u0433\u0443\u0441\u0442_\u0421\u0435\u043f\u0442\u0435\u043c\u0431\u0430\u0440_\u041e\u043a\u0442\u043e\u0431\u0430\u0440_\u041d\u043e\u0432\u0435\u043c\u0431\u0430\u0440_\u0414\u0435\u0446\u0435\u043c\u0431\u0430\u0440".split("_"),monthsShort:"\u0408\u0430\u043d._\u0424\u0435\u0431._\u041c\u0430\u0440._\u0410\u043f\u0440._\u041c\u0430\u0458_\u0408\u0443\u043d_\u0408\u0443\u043b_\u0410\u0432\u0433._\u0421\u0435\u043f._\u041e\u043a\u0442._\u041d\u043e\u0432._\u0414\u0435\u0446.".split("_"),weekStart:1,relativeTime:{future:"\u0437\u0430 %s",past:"\u043f\u0440\u0435 %s",s:"\u043d\u0435\u043a\u043e\u043b\u0438\u043a\u043e \u0441\u0435\u043a\u0443\u043d\u0434\u0438",m:a.relativeTimeFormatter,mm:a.relativeTimeFormatter,h:a.relativeTimeFormatter,hh:a.relativeTimeFormatter,d:a.relativeTimeFormatter,dd:a.relativeTimeFormatter,M:a.relativeTimeFormatter,MM:a.relativeTimeFormatter,y:a.relativeTimeFormatter,yy:a.relativeTimeFormatter},ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"D. M. YYYY.",LL:"D. MMMM YYYY.",LLL:"D. MMMM YYYY. H:mm",LLLL:"dddd, D. MMMM YYYY. H:mm"}};return r.default.locale(_,null,!0),_}(r(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3812.325f3251.chunk.js b/ydb/core/viewer/monitoring/static/js/3812.325f3251.chunk.js deleted file mode 100644 index ca045b710ebf..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3812.325f3251.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3812],{3685:(e,a,s)=>{s.d(a,{$:()=>o});var l=s(77506),t=s(33775),r=s(60712);const n=(0,l.cn)("ydb-entity-page-title");function o({entityName:e,status:a,id:s,className:l}){return(0,r.jsxs)("div",{className:n(null,l),children:[(0,r.jsx)("span",{className:n("prefix"),children:e}),(0,r.jsx)(t.k,{className:n("icon"),status:a,size:"s"}),s]})}},42655:(e,a,s)=>{s.d(a,{y:()=>c});var l=s(59284),t=s(89169),r=s(77506),n=s(66781),o=s(60712);const u=(0,r.cn)("ydb-info-viewer-skeleton"),i=()=>(0,o.jsxs)("div",{className:u("label"),children:[(0,o.jsx)(t.E,{className:u("label__text")}),(0,o.jsx)("div",{className:u("label__dots")})]}),c=({rows:e=8,className:a,delay:s=600})=>{const[r]=(0,n.y)(s);let c=(0,o.jsxs)(l.Fragment,{children:[(0,o.jsx)(i,{}),(0,o.jsx)(t.E,{className:u("value")})]});return r||(c=null),(0,o.jsx)("div",{className:u(null,a),children:[...new Array(e)].map(((e,a)=>(0,o.jsx)("div",{className:u("row"),children:c},`skeleton-row-${a}`)))})}},58389:(e,a,s)=>{s.d(a,{B:()=>c});var l=s(87184),t=s(77506),r=s(90053),n=s(70043),o=s(60712);const u=(0,t.cn)("ydb-page-meta");function i({items:e,loading:a}){return(0,o.jsx)("div",{className:u("info"),children:a?(0,o.jsx)(n.E,{className:u("skeleton")}):e.filter((e=>Boolean(e))).join("\xa0\xa0\xb7\xa0\xa0")})}function c({className:e,...a}){return(0,o.jsxs)(l.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:u(null,e),children:[(0,o.jsx)(i,{...a}),(0,o.jsx)(r.E,{})]})}},70043:(e,a,s)=>{s.d(a,{E:()=>n});var l=s(89169),t=s(66781),r=s(60712);const n=({delay:e=600,className:a})=>{const[s]=(0,t.y)(e);return s?(0,r.jsx)(l.E,{className:a}):null}},75510:(e,a,s)=>{s.r(a),s.d(a,{StorageGroupPage:()=>M});var l=s(59284),t=s(44992),r=s(61750),n=s(67087),o=s(3685),u=s(44508),i=s(42655),c=s(58389),p=s(87184),d=s(7435),g=s(56839),v=s(73891),m=s(41650),h=s(60073),b=s(15132),y=s(33775),f=s(48372);const x=JSON.parse('{"encryption":"Encryption","overall":"Overall","disk-space":"Disk Space","media-type":"Media Type","erasure-species":"Erasure Species","used-space":"Used Space","usage":"Usage","read-throughput":"Read Throughput","write-throughput":"Write Throughput","yes":"Yes","no":"No","group-generation":"Group Generation","latency":"Latency","allocation-units":"Units","state":"State","missing-disks":"Missing Disks","available":"Available Space","latency-put-tablet-log":"Latency (Put Tablet Log)","latency-put-user-data":"Latency (Put User Data)","latency-get-fast":"Latency (Get Fast)"}'),N=(0,f.g4)("storage-group-info",{en:x});var j=s(60712);function k({data:e,className:a,...s}){const{Encryption:l,Overall:t,DiskSpace:r,MediaType:n,ErasureSpecies:o,Used:u,Limit:i,Usage:c,Read:f,Write:x,GroupGeneration:k,Latency:S,AllocationUnits:w,State:G,MissingDisks:E,Available:L,LatencyPutTabletLogMs:P,LatencyPutUserDataMs:T,LatencyGetFastMs:$}=e||{},_=[];(0,d.f8)(k)&&_.push({label:N("group-generation"),value:k}),(0,d.f8)(o)&&_.push({label:N("erasure-species"),value:o}),(0,d.f8)(n)&&_.push({label:N("media-type"),value:n}),(0,d.f8)(l)&&_.push({label:N("encryption"),value:N(l?"yes":"no")}),(0,d.f8)(t)&&_.push({label:N("overall"),value:(0,j.jsx)(y.k,{status:t})}),(0,d.f8)(G)&&_.push({label:N("state"),value:G}),(0,d.f8)(E)&&_.push({label:N("missing-disks"),value:E});const I=[];return(0,d.f8)(u)&&(0,d.f8)(i)&&I.push({label:N("used-space"),value:(0,j.jsx)(b.O,{value:Number(u),capacity:Number(i),formatValues:g.vX,colorizeProgress:!0})}),(0,d.f8)(L)&&I.push({label:N("available"),value:(0,g.vX)(Number(L))}),(0,d.f8)(c)&&I.push({label:N("usage"),value:`${c.toFixed(2)}%`}),(0,d.f8)(r)&&I.push({label:N("disk-space"),value:(0,j.jsx)(y.k,{status:r})}),(0,d.f8)(S)&&I.push({label:N("latency"),value:(0,j.jsx)(y.k,{status:S})}),(0,d.f8)(P)&&I.push({label:N("latency-put-tablet-log"),value:(0,v.Xo)(P)}),(0,d.f8)(T)&&I.push({label:N("latency-put-user-data"),value:(0,v.Xo)(T)}),(0,d.f8)($)&&I.push({label:N("latency-get-fast"),value:(0,v.Xo)($)}),(0,d.f8)(w)&&I.push({label:N("allocation-units"),value:w}),(0,d.f8)(f)&&I.push({label:N("read-throughput"),value:(0,m.O4)(Number(f))}),(0,d.f8)(x)&&I.push({label:N("write-throughput"),value:(0,m.O4)(Number(x))}),(0,j.jsxs)(p.s,{className:a,gap:2,direction:"row",wrap:!0,children:[(0,j.jsx)(h.z_,{info:_,...s}),(0,j.jsx)(h.z_,{info:I,...s})]})}var S=s(67028),w=s(40174),G=s(10174),E=s(54090),L=s(77506),P=s(90182),T=s(99936);const $=JSON.parse('{"storage-group":"Storage Group","storage":"Storage","pool-name":"Pool Name"}'),_=(0,f.g4)("ydb-storage-group-page",{en:$}),I=(0,L.cn)("ydb-storage-group-page");function M(){var e,a;const s=(0,P.YQ)(),p=l.useRef(null),[{groupId:g}]=(0,n.useQueryParams)({groupId:n.StringParam});l.useEffect((()=>{s((0,w.g)("storageGroup",{groupId:g}))}),[s,g]);const[v]=(0,P.Nt)(),m=(0,S.YA)(),h=(0,S.Pm)(),b=G.S.useGetStorageGroupsInfoQuery((0,d.f8)(g)?{groupId:g,shouldUseGroupsHandler:m,with:"all",fieldsRequired:"all"}:t.hT,{pollingInterval:v,skip:!h}),y=null===(e=b.data)||void 0===e||null===(a=e.groups)||void 0===a?void 0:a[0],f=b.isFetching&&void 0===y;return(0,j.jsxs)("div",{className:I(null),ref:p,children:[(()=>{const e=g?`${_("storage-group")} ${g}`:_("storage-group");return(0,j.jsx)(r.mg,{titleTemplate:`%s - ${e} \u2014 YDB Monitoring`,defaultTitle:`${e} \u2014 YDB Monitoring`})})(),(()=>{if(!g)return null;const e=[`${_("pool-name")}: ${null===y||void 0===y?void 0:y.PoolName}`];return(0,j.jsx)(c.B,{className:I("meta"),loading:f,items:e})})(),(0,j.jsx)(o.$,{className:I("title"),entityName:_("storage-group"),status:(null===y||void 0===y?void 0:y.Overall)||E.m.Grey,id:g}),b.error?(0,j.jsx)(u.o,{error:b.error}):null,f?(0,j.jsx)(i.y,{className:I("info"),rows:10}):(0,j.jsx)(k,{data:y,className:I("info")}),g?(0,j.jsxs)(l.Fragment,{children:[(0,j.jsx)("div",{className:I("storage-title"),children:_("storage")}),(0,j.jsx)(T.z,{groupId:g,parentRef:p,viewContext:{groupId:null===g||void 0===g?void 0:g.toString()}})]}):null]})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3822.00ab6aaa.chunk.js b/ydb/core/viewer/monitoring/static/js/3822.00ab6aaa.chunk.js deleted file mode 100644 index 9ad5f4ed204c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3822.00ab6aaa.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 3822.00ab6aaa.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3822],{33822:(t,n,e)=>{e.r(n),e.d(n,{conf:()=>r,language:()=>s});var r={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"}]};function a(t){let n=[];const e=t.split(/\t+|\r+|\n+| +/);for(let r=0;r0&&n.push(e[r]);return n}var o=/[_\p{XID_Start}]\p{XID_Continue}*/u,i="variable.predefined",s={tokenPostfix:".wgsl",defaultToken:"invalid",unicode:!0,atoms:a("true false"),keywords:a("\n\t\t\t alias\n\t\t\t break\n\t\t\t case\n\t\t\t const\n\t\t\t const_assert\n\t\t\t continue\n\t\t\t continuing\n\t\t\t default\n\t\t\t diagnostic\n\t\t\t discard\n\t\t\t else\n\t\t\t enable\n\t\t\t fn\n\t\t\t for\n\t\t\t if\n\t\t\t let\n\t\t\t loop\n\t\t\t override\n\t\t\t requires\n\t\t\t return\n\t\t\t struct\n\t\t\t switch\n\t\t\t var\n\t\t\t while\n\t\t\t "),reserved:a("\n\t\t\t NULL\n\t\t\t Self\n\t\t\t abstract\n\t\t\t active\n\t\t\t alignas\n\t\t\t alignof\n\t\t\t as\n\t\t\t asm\n\t\t\t asm_fragment\n\t\t\t async\n\t\t\t attribute\n\t\t\t auto\n\t\t\t await\n\t\t\t become\n\t\t\t binding_array\n\t\t\t cast\n\t\t\t catch\n\t\t\t class\n\t\t\t co_await\n\t\t\t co_return\n\t\t\t co_yield\n\t\t\t coherent\n\t\t\t column_major\n\t\t\t common\n\t\t\t compile\n\t\t\t compile_fragment\n\t\t\t concept\n\t\t\t const_cast\n\t\t\t consteval\n\t\t\t constexpr\n\t\t\t constinit\n\t\t\t crate\n\t\t\t debugger\n\t\t\t decltype\n\t\t\t delete\n\t\t\t demote\n\t\t\t demote_to_helper\n\t\t\t do\n\t\t\t dynamic_cast\n\t\t\t enum\n\t\t\t explicit\n\t\t\t export\n\t\t\t extends\n\t\t\t extern\n\t\t\t external\n\t\t\t fallthrough\n\t\t\t filter\n\t\t\t final\n\t\t\t finally\n\t\t\t friend\n\t\t\t from\n\t\t\t fxgroup\n\t\t\t get\n\t\t\t goto\n\t\t\t groupshared\n\t\t\t highp\n\t\t\t impl\n\t\t\t implements\n\t\t\t import\n\t\t\t inline\n\t\t\t instanceof\n\t\t\t interface\n\t\t\t layout\n\t\t\t lowp\n\t\t\t macro\n\t\t\t macro_rules\n\t\t\t match\n\t\t\t mediump\n\t\t\t meta\n\t\t\t mod\n\t\t\t module\n\t\t\t move\n\t\t\t mut\n\t\t\t mutable\n\t\t\t namespace\n\t\t\t new\n\t\t\t nil\n\t\t\t noexcept\n\t\t\t noinline\n\t\t\t nointerpolation\n\t\t\t noperspective\n\t\t\t null\n\t\t\t nullptr\n\t\t\t of\n\t\t\t operator\n\t\t\t package\n\t\t\t packoffset\n\t\t\t partition\n\t\t\t pass\n\t\t\t patch\n\t\t\t pixelfragment\n\t\t\t precise\n\t\t\t precision\n\t\t\t premerge\n\t\t\t priv\n\t\t\t protected\n\t\t\t pub\n\t\t\t public\n\t\t\t readonly\n\t\t\t ref\n\t\t\t regardless\n\t\t\t register\n\t\t\t reinterpret_cast\n\t\t\t require\n\t\t\t resource\n\t\t\t restrict\n\t\t\t self\n\t\t\t set\n\t\t\t shared\n\t\t\t sizeof\n\t\t\t smooth\n\t\t\t snorm\n\t\t\t static\n\t\t\t static_assert\n\t\t\t static_cast\n\t\t\t std\n\t\t\t subroutine\n\t\t\t super\n\t\t\t target\n\t\t\t template\n\t\t\t this\n\t\t\t thread_local\n\t\t\t throw\n\t\t\t trait\n\t\t\t try\n\t\t\t type\n\t\t\t typedef\n\t\t\t typeid\n\t\t\t typename\n\t\t\t typeof\n\t\t\t union\n\t\t\t unless\n\t\t\t unorm\n\t\t\t unsafe\n\t\t\t unsized\n\t\t\t use\n\t\t\t using\n\t\t\t varying\n\t\t\t virtual\n\t\t\t volatile\n\t\t\t wgsl\n\t\t\t where\n\t\t\t with\n\t\t\t writeonly\n\t\t\t yield\n\t\t\t "),predeclared_enums:a("\n\t\tread write read_write\n\t\tfunction private workgroup uniform storage\n\t\tperspective linear flat\n\t\tcenter centroid sample\n\t\tvertex_index instance_index position front_facing frag_depth\n\t\t\tlocal_invocation_id local_invocation_index\n\t\t\tglobal_invocation_id workgroup_id num_workgroups\n\t\t\tsample_index sample_mask\n\t\trgba8unorm\n\t\trgba8snorm\n\t\trgba8uint\n\t\trgba8sint\n\t\trgba16uint\n\t\trgba16sint\n\t\trgba16float\n\t\tr32uint\n\t\tr32sint\n\t\tr32float\n\t\trg32uint\n\t\trg32sint\n\t\trg32float\n\t\trgba32uint\n\t\trgba32sint\n\t\trgba32float\n\t\tbgra8unorm\n"),predeclared_types:a("\n\t\tbool\n\t\tf16\n\t\tf32\n\t\ti32\n\t\tsampler sampler_comparison\n\t\ttexture_depth_2d\n\t\ttexture_depth_2d_array\n\t\ttexture_depth_cube\n\t\ttexture_depth_cube_array\n\t\ttexture_depth_multisampled_2d\n\t\ttexture_external\n\t\ttexture_external\n\t\tu32\n\t\t"),predeclared_type_generators:a("\n\t\tarray\n\t\tatomic\n\t\tmat2x2\n\t\tmat2x3\n\t\tmat2x4\n\t\tmat3x2\n\t\tmat3x3\n\t\tmat3x4\n\t\tmat4x2\n\t\tmat4x3\n\t\tmat4x4\n\t\tptr\n\t\ttexture_1d\n\t\ttexture_2d\n\t\ttexture_2d_array\n\t\ttexture_3d\n\t\ttexture_cube\n\t\ttexture_cube_array\n\t\ttexture_multisampled_2d\n\t\ttexture_storage_1d\n\t\ttexture_storage_2d\n\t\ttexture_storage_2d_array\n\t\ttexture_storage_3d\n\t\tvec2\n\t\tvec3\n\t\tvec4\n\t\t"),predeclared_type_aliases:a("\n\t\tvec2i vec3i vec4i\n\t\tvec2u vec3u vec4u\n\t\tvec2f vec3f vec4f\n\t\tvec2h vec3h vec4h\n\t\tmat2x2f mat2x3f mat2x4f\n\t\tmat3x2f mat3x3f mat3x4f\n\t\tmat4x2f mat4x3f mat4x4f\n\t\tmat2x2h mat2x3h mat2x4h\n\t\tmat3x2h mat3x3h mat3x4h\n\t\tmat4x2h mat4x3h mat4x4h\n\t\t"),predeclared_intrinsics:a("\n bitcast all any select arrayLength abs acos acosh asin asinh atan atanh atan2\n ceil clamp cos cosh countLeadingZeros countOneBits countTrailingZeros cross\n degrees determinant distance dot exp exp2 extractBits faceForward firstLeadingBit\n firstTrailingBit floor fma fract frexp inverseBits inverseSqrt ldexp length\n log log2 max min mix modf normalize pow quantizeToF16 radians reflect refract\n reverseBits round saturate sign sin sinh smoothstep sqrt step tan tanh transpose\n trunc dpdx dpdxCoarse dpdxFine dpdy dpdyCoarse dpdyFine fwidth fwidthCoarse fwidthFine\n textureDimensions textureGather textureGatherCompare textureLoad textureNumLayers\n textureNumLevels textureNumSamples textureSample textureSampleBias textureSampleCompare\n textureSampleCompareLevel textureSampleGrad textureSampleLevel textureSampleBaseClampToEdge\n textureStore atomicLoad atomicStore atomicAdd atomicSub atomicMax atomicMin\n atomicAnd atomicOr atomicXor atomicExchange atomicCompareExchangeWeak pack4x8snorm\n pack4x8unorm pack2x16snorm pack2x16unorm pack2x16float unpack4x8snorm unpack4x8unorm\n unpack2x16snorm unpack2x16unorm unpack2x16float storageBarrier workgroupBarrier\n workgroupUniformLoad\n"),operators:a("\n\t\t\t\t\t &\n\t\t\t\t\t &&\n\t\t\t\t\t ->\n\t\t\t\t\t /\n\t\t\t\t\t =\n\t\t\t\t\t ==\n\t\t\t\t\t !=\n\t\t\t\t\t >\n\t\t\t\t\t >=\n\t\t\t\t\t <\n\t\t\t\t\t <=\n\t\t\t\t\t %\n\t\t\t\t\t -\n\t\t\t\t\t --\n\t\t\t\t\t +\n\t\t\t\t\t ++\n\t\t\t\t\t |\n\t\t\t\t\t ||\n\t\t\t\t\t *\n\t\t\t\t\t <<\n\t\t\t\t\t >>\n\t\t\t\t\t +=\n\t\t\t\t\t -=\n\t\t\t\t\t *=\n\t\t\t\t\t /=\n\t\t\t\t\t %=\n\t\t\t\t\t &=\n\t\t\t\t\t |=\n\t\t\t\t\t ^=\n\t\t\t\t\t >>=\n\t\t\t\t\t <<=\n\t\t\t\t\t "),symbols:/[!%&*+\-\.\/:;<=>^|_~,]+/,tokenizer:{root:[[/enable|requires|diagnostic/,"keyword","@directive"],[o,{cases:{"@atoms":i,"@keywords":"keyword","@reserved":"invalid","@predeclared_enums":i,"@predeclared_types":i,"@predeclared_type_generators":i,"@predeclared_type_aliases":i,"@predeclared_intrinsics":i,"@default":"identifier"}}],{include:"@commentOrSpace"},{include:"@numbers"},[/[{}()\[\]]/,"@brackets"],["@","annotation","@attribute"],[/@symbols/,{cases:{"@operators":"operator","@default":"delimiter"}}],[/./,"invalid"]],commentOrSpace:[[/\s+/,"white"],[/\/\*/,"comment","@blockComment"],[/\/\/.*$/,"comment"]],blockComment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@push"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],attribute:[{include:"@commentOrSpace"},[/\w+/,"annotation","@pop"]],directive:[{include:"@commentOrSpace"},[/[()]/,"@brackets"],[/,/,"delimiter"],[o,"meta.content"],[/;/,"delimiter","@pop"]],numbers:[[/0[fh]/,"number.float"],[/[1-9][0-9]*[fh]/,"number.float"],[/[0-9]*\.[0-9]+([eE][+-]?[0-9]+)?[fh]?/,"number.float"],[/[0-9]+\.[0-9]*([eE][+-]?[0-9]+)?[fh]?/,"number.float"],[/[0-9]+[eE][+-]?[0-9]+[fh]?/,"number.float"],[/0[xX][0-9a-fA-F]*\.[0-9a-fA-F]+(?:[pP][+-]?[0-9]+[fh]?)?/,"number.hex"],[/0[xX][0-9a-fA-F]+\.[0-9a-fA-F]*(?:[pP][+-]?[0-9]+[fh]?)?/,"number.hex"],[/0[xX][0-9a-fA-F]+[pP][+-]?[0-9]+[fh]?/,"number.hex"],[/0[xX][0-9a-fA-F]+[iu]?/,"number.hex"],[/[1-9][0-9]*[iu]?/,"number"],[/0[iu]?/,"number"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/38527.70d9dd2b.chunk.js b/ydb/core/viewer/monitoring/static/js/38527.70d9dd2b.chunk.js new file mode 100644 index 000000000000..0197a7ae693d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/38527.70d9dd2b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[38527],{45659:(e,t,i)=>{i.d(t,{Q:()=>v});var s=i(87184),o=i(92459),n=i(7435),a=i(46549),l=i(56839),d=i(31684),r=i(12888),c=i(18863),u=i(25196),m=i(15132),p=i(33775),g=i(50672),h=i(60712);function v({pDisk:e,nodeId:t,withPDiskPageLink:i,className:v}){const D=(0,r.X)(),[k,f,b,I]=function({pDisk:e,nodeId:t,withPDiskPageLink:i,isUserAllowedToMakeChanges:r}){const{PDiskId:c,Path:v,Guid:D,Category:k,Type:f,Device:b,Realtime:I,State:S,SerialNumber:x,TotalSize:y,AllocatedSize:w,StatusV2:N,NumActiveSlots:j,ExpectedSlotCount:T,LogUsedSize:P,LogTotalSize:E,SystemSize:C,SharedWithOs:z}=e||{},M=[];(0,n.f8)(k)&&M.push({label:(0,g.D)("type"),value:f}),(0,n.f8)(v)&&M.push({label:(0,g.D)("path"),value:v}),(0,n.f8)(D)&&M.push({label:(0,g.D)("guid"),value:D}),x&&M.push({label:(0,g.D)("serial-number"),value:x}),z&&M.push({label:(0,g.D)("shared-with-os"),value:(0,g.D)("yes")});const O=[];(0,n.f8)(N)&&O.push({label:(0,g.D)("drive-status"),value:N}),(0,n.f8)(S)&&O.push({label:(0,g.D)("state"),value:S}),(0,n.f8)(b)&&O.push({label:(0,g.D)("device"),value:(0,h.jsx)(p.k,{status:b})}),(0,n.f8)(I)&&O.push({label:(0,g.D)("realtime"),value:(0,h.jsx)(p.k,{status:I})});const A=[];A.push({label:(0,g.D)("space"),value:(0,h.jsx)(m.O,{value:w,capacity:y,formatValues:l.vX,colorizeProgress:!0})}),(0,n.f8)(j)&&(0,n.f8)(T)&&A.push({label:(0,g.D)("slots"),value:(0,h.jsx)(m.O,{value:j,capacity:T})}),(0,n.f8)(P)&&(0,n.f8)(E)&&A.push({label:(0,g.D)("log-size"),value:(0,h.jsx)(m.O,{value:P,capacity:E,formatValues:l.vX})}),(0,n.f8)(C)&&A.push({label:(0,g.D)("system-size"),value:(0,a.z3)({value:C})});const _=[];if((i||r)&&(0,n.f8)(c)&&(0,n.f8)(t)){const e=(0,o.Ck)(c,t),n=(0,d.ar)({nodeId:t,pDiskId:c});_.push({label:(0,g.D)("links"),value:(0,h.jsxs)(s.s,{wrap:"wrap",gap:2,children:[i&&(0,h.jsx)(u.K,{title:(0,g.D)("pdisk-page"),url:e,external:!1}),r&&(0,h.jsx)(u.K,{title:(0,g.D)("developer-ui"),url:n})]})})}return[M,O,A,_]}({pDisk:e,nodeId:t,withPDiskPageLink:i,isUserAllowedToMakeChanges:D});return(0,h.jsxs)(s.s,{className:v,gap:2,direction:"row",wrap:!0,children:[(0,h.jsxs)(s.s,{direction:"column",gap:2,width:500,children:[(0,h.jsx)(c.z,{info:k,renderEmptyState:()=>null}),(0,h.jsx)(c.z,{info:b,renderEmptyState:()=>null})]}),(0,h.jsxs)(s.s,{direction:"column",gap:2,width:500,children:[(0,h.jsx)(c.z,{info:f,renderEmptyState:()=>null}),(0,h.jsx)(c.z,{info:I,renderEmptyState:()=>null})]})]})}},69134:(e,t,i)=>{i.r(t),i.d(t,{PDiskPage:()=>be});var s=i(59284),o=i(76938),n=i(99991),a=i(23871),l=i(44992),d=i(61750),r=i(80987),c=i(370),u=i(22983),m=i(3685),p=i(44508),g=i(42655),h=i(82015),v=i(45659),D=i(58389),k=i(92459),f=i(21334),b=i(67028),I=i(40174),S=i(7187),x=i(68712),y=i(7435),w=i(27295),N=i(78034);const j=f.F.injectEndpoints({endpoints:e=>({getPdiskInfo:e.query({queryFn:async({nodeId:e,pDiskId:t},{signal:i,getState:s,dispatch:o})=>{let n;n=await(0,x.FC)("/pdisk/info",void 0,{getState:s,dispatch:o})>0?window.api.pdisk.getPDiskInfo({nodeId:e,pDiskId:t},{signal:i}):window.api.viewer.getNodeWhiteboardPDiskInfo({nodeId:e,pDiskId:t},{signal:i}).then((e=>e.PDiskStateInfo?{Whiteboard:{PDisk:{...e.PDiskStateInfo[0],ExpectedSlotCount:void 0}}}:{}));try{const t=await Promise.all([n,window.api.viewer.getNodeInfo(e,{signal:i})]);return{data:function([e={},t]){var i,s,o;const n=null===(i=t.SystemStateInfo)||void 0===i?void 0:i[0],a=(0,N.q1)(n),{BSC:l={},Whiteboard:d={}}=e||{},{PDisk:r={},VDisks:c=[]}=d,{PDisk:u={}}=l,m=(0,w.or)({...u,...r}),p=null!==(s=m.NodeId)&&void 0!==s?s:a.NodeId,{LogUsedSize:g,LogTotalSize:h,TotalSize:v,SystemSize:D,ExpectedSlotCount:k,SlotSize:f}=m;let b;if((0,y.f8)(h)){const e=100*Number(g)/Number(h);b={SlotType:"log",Used:Number(g),Total:Number(h),UsagePercent:e,Severity:(0,S.SW)(e),SlotData:{LogUsedSize:g,LogTotalSize:h,SystemSize:D}}}const I=c.map((e=>(0,w.WT)({...e,NodeId:p})));I.sort(((e,t)=>Number(t.VDiskSlotId)-Number(e.VDiskSlotId)));const x=I.map((e=>{var t;const i=(0,S.SW)(e.AllocatedPercent);return{SlotType:"vDisk",Id:null===(t=e.VDiskId)||void 0===t?void 0:t.GroupID,Title:e.StoragePoolName,Severity:i,Used:Number(e.AllocatedSize),Total:Number(e.TotalSize),UsagePercent:e.AllocatedPercent,SlotData:e}}));let j=[];if(k&&k>x.length){const e=k-x.length;let t=Number(f);if(isNaN(t)){const i=x.reduce(((e,t)=>t.Total?e+t.Total:e),0);t=(Number(v)-i-Number(h))/e}j=(0,y._e)(e).map((()=>({SlotType:"empty",Total:t,Severity:1,SlotData:{Size:t}})))}const T=[...x,...j];return b&&T.length>0&&T.unshift(b),{...m,NodeId:p,NodeHost:a.Host,NodeType:null===(o=a.Roles)||void 0===o?void 0:o[0],NodeDC:a.DC,SlotItems:T}}(t)}}catch(a){return{error:a}}},providesTags:(e,t,i)=>["All",{type:"PDiskData",id:(0,S.r$)({nodeId:i.nodeId,pDiskId:i.pDiskId})}]})}),overrideExisting:"throw"});var T=i(77506),P=i(90182),E=i(12888),C=i(47199),z=i(13066),M=i(40569),O=i(84375),A=i(84476),_=i(55974),R=i(42829),L=i(48372);const V=JSON.parse('{"fqdn":"FQDN","pdisk":"PDisk","node":"Node","storage":"Storage","space-distribution":"Space distribution","empty-slot":"Empty slot","log":"Log","label.log-size":"Log Size","label.system-size":"System Size","label.slot-size":"Slot Size","no-slots-data":"No slots data","restart-pdisk-button":"Restart PDisk","force-restart-pdisk-button":"Restart anyway","restart-pdisk-not-allowed":"You don\'t have enough rights to restart PDisk","restart-pdisk-dialog-header":"Restart PDisk","restart-pdisk-dialog-text":"PDisk will be restarted. Do you want to proceed?","decommission-none":"None","decommission-imminent":"Imminent","decommission-pending":"Pending","decommission-rejected":"Rejected","decommission-label":"{{decommission}} decommission","decommission-button":"Decommission","decommission-change-not-allowed":"You don\'t have enough rights to change PDisk decommission","decommission-dialog-title":"Change decommission status","decommission-dialog-force-change":"Change anyway","decommission-dialog-imminent-warning":"This will start imminent decommission. Existing slots will be moved from the disk","decommission-dialog-pending-warning":"This will start pending decommission. Decommission will be planned for this disk, but will not start immediatelly. Existing slots will not be moved from the disk, but no new slots will be allocated on it","decommission-dialog-rejected-warning":"This will start rejected decommission. No slots from other disks are placed on this disk in the process of decommission","decommission-dialog-none-warning":"This will reset decommission mode, allowing the disk to be used by the storage"}'),$=(0,L.g4)("ydb-pDisk-page",{en:V});var U,B,H,W;function G(){return G=Object.assign?Object.assign.bind():function(e){for(var t=1;tt("DECOMMIT_NONE"),hidden:!e||"DECOMMIT_NONE"===e||"DECOMMIT_UNSET"===e},{text:$("decommission-pending"),action:()=>t("DECOMMIT_PENDING"),hidden:"DECOMMIT_PENDING"===e},{text:$("decommission-rejected"),action:()=>t("DECOMMIT_REJECTED"),hidden:"DECOMMIT_REJECTED"===e},{text:$("decommission-imminent"),theme:"danger",action:()=>t("DECOMMIT_IMMINENT"),hidden:"DECOMMIT_IMMINENT"===e}]}(e,l);return(0,X.jsxs)(s.Fragment,{children:[(0,X.jsx)(M.r,{renderSwitcher:e=>(0,X.jsx)(q,{popoverDisabled:n,loading:d,disabled:o,...e}),items:m,popupProps:{className:F("popup")}}),(0,X.jsx)(_.g,{visible:Boolean(a),header:$("decommission-dialog-title"),text:Q(a),withRetry:c,withCheckBox:!0,retryButtonText:$("decommission-dialog-force-change"),onConfirm:async e=>{r(!0),await t(a,e)},onConfirmActionSuccess:async()=>{u(!1),await(0,y.uk)(5e3);try{await i()}finally{r(!1)}},onConfirmActionError:e=>{u((0,R.D)(e)),r(!1)},onClose:()=>{l(void 0)}})]})}function q({popoverDisabled:e,...t}){return(0,X.jsx)(O.A,{content:$("decommission-change-not-allowed"),placement:"right",disabled:e,children:(0,X.jsxs)(A.$,{view:"normal",className:F("button"),...t,children:[(0,X.jsx)(n.I,{data:J}),$("decommission-button"),(0,X.jsx)(n.I,{data:z.A})]})})}var K=i(47665);function Z(e){return $("decommission-label",{decommission:e})}function ee({decommission:e}){return"DECOMMIT_IMMINENT"===e?(0,X.jsx)(K.J,{theme:"danger",size:"m",children:Z($("decommission-imminent"))}):"DECOMMIT_PENDING"===e?(0,X.jsx)(K.J,{theme:"warning",size:"m",children:Z($("decommission-pending"))}):"DECOMMIT_REJECTED"===e?(0,X.jsx)(K.J,{theme:"normal",size:"m",children:Z($("decommission-rejected"))}):null}var te=i(88226),ie=i(13096),se=i(60073),oe=i(44294),ne=i(15132),ae=i(67808),le=i(46549),de=i(56839);const re=(0,T.cn)("ydb-pdisk-space-distribution"),ce=40;function ue({data:e}){const{SlotItems:t}=e,{PDiskId:i,NodeId:s}=e,o=ce*((null===t||void 0===t?void 0:t.length)||1);return null!==t&&void 0!==t&&t.length?(0,X.jsx)("div",{className:re(null),style:{height:o,minHeight:o},children:(0,X.jsx)(te.V,{className:re("pdisk-bar"),severity:e.Severity,diskAllocatedPercent:e.AllocatedPercent,content:null===t||void 0===t?void 0:t.map(((e,t)=>(0,X.jsx)(me,{item:e,pDiskId:i,nodeId:s},t))),faded:!0})}):$("no-slots-data")}function me({item:e,pDiskId:t,nodeId:i}){return(0,X.jsx)("div",{className:re("slot-wrapper"),style:{flexGrow:Number(e.Total)||1},children:(()=>{if("vDisk"===e.SlotType){var s;const o=(0,y.f8)(null===(s=e.SlotData)||void 0===s?void 0:s.VDiskSlotId)&&(0,y.f8)(t)&&(0,y.f8)(i)?(0,k.yX)({vDiskSlotId:e.SlotData.VDiskSlotId,pDiskId:t,nodeId:i}):void 0;return(0,X.jsx)(ie.P,{renderPopupContent:()=>(0,X.jsx)(ae.E,{data:e.SlotData,withTitle:!0}),contentClassName:re("vdisk-popup"),placement:["right","top"],children:(0,X.jsx)(oe.E,{to:o,children:(0,X.jsx)(te.V,{className:re("slot"),severity:e.Severity,diskAllocatedPercent:e.UsagePercent,content:(0,X.jsx)(pe,{id:e.Id,title:e.Title,used:e.Used,total:e.Total})})})})}return function(e){return"log"===e.SlotType}(e)?(0,X.jsx)(ie.P,{renderPopupContent:()=>(0,X.jsx)(ge,{data:e.SlotData}),contentClassName:re("vdisk-popup"),placement:["right","top"],children:(0,X.jsx)(te.V,{className:re("slot"),severity:e.Severity,diskAllocatedPercent:e.UsagePercent,content:(0,X.jsx)(pe,{title:$("log"),used:e.Used,total:e.Total})})}):function(e){return"empty"===e.SlotType}(e)?(0,X.jsx)(ie.P,{renderPopupContent:()=>(0,X.jsx)(he,{data:e.SlotData}),contentClassName:re("vdisk-popup"),placement:["right","top"],children:(0,X.jsx)(te.V,{className:re("slot"),severity:e.Severity,empty:!0,content:(0,X.jsx)(pe,{title:$("empty-slot"),used:e.Total})})}):null})()})}function pe({id:e,title:t,used:i,total:s}){return(0,X.jsxs)("div",{className:re("slot-content"),children:[(0,X.jsxs)("span",{children:[(0,y.f8)(e)?(0,X.jsx)("span",{className:re("slot-id"),children:e}):null,t]}),(0,X.jsx)("span",{className:re("slot-size"),children:(()=>{const[e,t]=(0,de.vX)(i,s);return s?`${e} / ${t}`:e})()})]})}function ge({data:e}){const{LogTotalSize:t,LogUsedSize:i,SystemSize:s}=e,o=[{label:$("label.log-size"),value:(0,X.jsx)(ne.O,{value:i,capacity:t,formatValues:de.vX})}];return(0,y.f8)(s)&&o.push({label:$("label.system-size"),value:(0,le.z3)({value:s})}),(0,X.jsx)(se.z_,{title:$("log"),info:o})}function he({data:e}){const{Size:t}=e,i=[{label:$("label.slot-size"),value:(0,le.z3)({value:t})}];return(0,X.jsx)(se.z_,{title:$("empty-slot"),info:i})}const ve=(0,T.cn)("ydb-pdisk-page"),De={spaceDistribution:"spaceDistribution",storage:"storage"},ke=[{id:De.spaceDistribution,get title(){return $("space-distribution")}},{id:De.storage,get title(){return $("storage")}}],fe=c.z.nativeEnum(De).catch(De.spaceDistribution);function be(){const e=(0,P.YQ)(),t=(0,E.X)(),i=(0,b.c2)(),c=s.useRef(null),[{nodeId:x,pDiskId:w,activeTab:N}]=(0,r.useQueryParams)({activeTab:r.StringParam,nodeId:r.StringParam,pDiskId:r.StringParam}),T=(0,y.f8)(x)&&(0,y.f8)(w),z=fe.parse(N);s.useEffect((()=>{e((0,I.g)("pDisk",{nodeId:x,pDiskId:w}))}),[e,x,w]);const[M]=(0,P.Nt)(),O=T?{nodeId:x,pDiskId:w}:l.hT,A=j.useGetPdiskInfoQuery(O,{pollingInterval:M}),_=A.isFetching&&void 0===A.currentData,R=A.currentData,{NodeHost:L,NodeId:V,NodeType:U,NodeDC:B,Severity:H,DecommitStatus:W}=R||{},G=async e=>{if(T){const t=await window.api.pdisk[i?"restartPDisk":"restartPDiskOld"]({nodeId:x,pDiskId:w,force:e});if(!1===(null===t||void 0===t?void 0:t.result)){throw{statusText:t.error,retryPossible:t.forceRetryPossible}}}},J=async(e,t)=>{if(T){const i=await window.api.pdisk.changePDiskStatus({nodeId:x,pDiskId:w,force:t,decommissionStatus:e});if(!1===(null===i||void 0===i?void 0:i.result)){throw{statusText:i.error,retryPossible:i.forceRetryPossible}}}},F=()=>{T&&e(f.F.util.invalidateTags([{type:"PDiskData",id:(0,S.r$)({nodeId:x,pDiskId:w})}]),"StorageData")};return(0,X.jsxs)("div",{className:ve(null),ref:c,children:[(()=>{const e=w?`${$("pdisk")} ${w}`:$("pdisk"),t=L||$("node");return(0,X.jsx)(d.mg,{titleTemplate:`%s - ${e} \u2014 ${t} \u2014 YDB Monitoring`,defaultTitle:`${e} \u2014 ${t} \u2014 YDB Monitoring`})})(),(()=>{const e=L?`${$("fqdn")}: ${L}`:void 0,t=V?`${$("node")}: ${V}`:void 0;return(0,X.jsx)(D.B,{loading:_,items:[e,t,U,B],className:ve("meta")})})(),(0,X.jsxs)("div",{className:ve("title"),children:[(0,X.jsx)(m.$,{entityName:$("pdisk"),status:(0,S.XY)(H),id:(0,S.r$)({nodeId:x,pDiskId:w})}),(0,X.jsx)(ee,{decommission:W})]}),(0,X.jsxs)("div",{className:ve("controls"),children:[(0,X.jsxs)(u.B,{onConfirmAction:G,onConfirmActionSuccess:F,buttonDisabled:!T||!t,buttonView:"normal",dialogHeader:$("restart-pdisk-dialog-header"),dialogText:$("restart-pdisk-dialog-text"),retryButtonText:$("force-restart-pdisk-button"),withPopover:!0,popoverContent:$("restart-pdisk-not-allowed"),popoverDisabled:t,children:[(0,X.jsx)(n.I,{data:o.A}),$("restart-pdisk-button")]}),i?(0,X.jsx)(Y,{decommission:W,onConfirmAction:J,onConfirmActionSuccess:F,buttonDisabled:!T||!t,popoverDisabled:t}):null]}),A.error?(0,X.jsx)(p.o,{error:A.error}):null,_?(0,X.jsx)(g.y,{className:ve("info"),rows:10}):(0,X.jsx)(v.Q,{pDisk:R,nodeId:x,className:ve("info")}),(0,X.jsx)("div",{className:ve("tabs"),children:(0,X.jsx)(a.t,{size:"l",items:ke,activeTab:z,wrapTo:({id:e},t)=>{const i=T?(0,k.Ck)(w,x,{activeTab:e}):void 0;return(0,X.jsx)(h.E,{to:i,children:t},e)}})}),(()=>{switch(z){case"spaceDistribution":return R?(0,X.jsx)("div",{className:ve("disk-distribution"),children:(0,X.jsx)(ue,{data:R})}):null;case"storage":return T?(0,X.jsx)(C.z,{nodeId:x,pDiskId:w,scrollContainerRef:c,viewContext:{nodeId:null===x||void 0===x?void 0:x.toString(),pDiskId:null===w||void 0===w?void 0:w.toString()}}):null;default:return null}})()]})}},76938:(e,t,i)=>{i.d(t,{A:()=>o});var s=i(59284);const o=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 1 1-6.445 7.348.75.75 0 1 1 1.487-.194A5.001 5.001 0 1 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 0 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5",clipRule:"evenodd"}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/38718.bf415be7.chunk.js b/ydb/core/viewer/monitoring/static/js/38718.bf415be7.chunk.js new file mode 100644 index 000000000000..072b73bfe33b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/38718.bf415be7.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[38718],{38718:(E,_,e)=>{e.d(_,{default:()=>R});var I=e(90095);const R=e.n(I)()},89343:E=>{function _(E){E.languages.c=E.languages.extend("clike",{comment:{pattern:/\/\/(?:[^\r\n\\]|\\(?:\r\n?|\n|(?![\r\n])))*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"class-name":{pattern:/(\b(?:enum|struct)\s+(?:__attribute__\s*\(\([\s\S]*?\)\)\s*)?)\w+|\b[a-z]\w*_t\b/,lookbehind:!0},keyword:/\b(?:_Alignas|_Alignof|_Atomic|_Bool|_Complex|_Generic|_Imaginary|_Noreturn|_Static_assert|_Thread_local|__attribute__|asm|auto|break|case|char|const|continue|default|do|double|else|enum|extern|float|for|goto|if|inline|int|long|register|return|short|signed|sizeof|static|struct|switch|typedef|typeof|union|unsigned|void|volatile|while)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ful]{0,4}/i,operator:/>>=?|<<=?|->|([-+&|:])\1|[?:~]|[-+*/%&|^!=<>]=?/}),E.languages.insertBefore("c","string",{char:{pattern:/'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n]){0,32}'/,greedy:!0}}),E.languages.insertBefore("c","string",{macro:{pattern:/(^[\t ]*)#\s*[a-z](?:[^\r\n\\/]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{string:[{pattern:/^(#\s*include\s*)<[^>]+>/,lookbehind:!0},E.languages.c.string],char:E.languages.c.char,comment:E.languages.c.comment,"macro-name":[{pattern:/(^#\s*define\s+)\w+\b(?!\()/i,lookbehind:!0},{pattern:/(^#\s*define\s+)\w+\b(?=\()/i,lookbehind:!0,alias:"function"}],directive:{pattern:/^(#\s*)[a-z]+/,lookbehind:!0,alias:"keyword"},"directive-hash":/^#/,punctuation:/##|\\(?=[\r\n])/,expression:{pattern:/\S[\s\S]*/,inside:E.languages.c}}}}),E.languages.insertBefore("c","function",{constant:/\b(?:EOF|NULL|SEEK_CUR|SEEK_END|SEEK_SET|__DATE__|__FILE__|__LINE__|__TIMESTAMP__|__TIME__|__func__|stderr|stdin|stdout)\b/}),delete E.languages.c.boolean}E.exports=_,_.displayName="c",_.aliases=[]},90095:(E,_,e)=>{var I=e(89343);function R(E){E.register(I),function(E){E.languages.opencl=E.languages.extend("c",{keyword:/\b(?:(?:__)?(?:constant|global|kernel|local|private|read_only|read_write|write_only)|__attribute__|auto|(?:bool|u?(?:char|int|long|short)|half|quad)(?:2|3|4|8|16)?|break|case|complex|const|continue|(?:double|float)(?:16(?:x(?:1|2|4|8|16))?|1x(?:1|2|4|8|16)|2(?:x(?:1|2|4|8|16))?|3|4(?:x(?:1|2|4|8|16))?|8(?:x(?:1|2|4|8|16))?)?|default|do|else|enum|extern|for|goto|if|imaginary|inline|packed|pipe|register|restrict|return|signed|sizeof|static|struct|switch|typedef|uniform|union|unsigned|void|volatile|while)\b/,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[fuhl]{0,4}/i,boolean:/\b(?:false|true)\b/,"constant-opencl-kernel":{pattern:/\b(?:CHAR_(?:BIT|MAX|MIN)|CLK_(?:ADDRESS_(?:CLAMP(?:_TO_EDGE)?|NONE|REPEAT)|FILTER_(?:LINEAR|NEAREST)|(?:GLOBAL|LOCAL)_MEM_FENCE|NORMALIZED_COORDS_(?:FALSE|TRUE))|CL_(?:BGRA|(?:HALF_)?FLOAT|INTENSITY|LUMINANCE|A?R?G?B?[Ax]?|(?:(?:UN)?SIGNED|[US]NORM)_(?:INT(?:8|16|32))|UNORM_(?:INT_101010|SHORT_(?:555|565)))|(?:DBL|FLT|HALF)_(?:DIG|EPSILON|(?:MAX|MIN)(?:(?:_10)?_EXP)?|MANT_DIG)|FLT_RADIX|HUGE_VALF?|(?:INT|LONG|SCHAR|SHRT)_(?:MAX|MIN)|INFINITY|MAXFLOAT|M_(?:[12]_PI|2_SQRTPI|E|LN(?:2|10)|LOG(?:2|10)E?|PI(?:_[24])?|SQRT(?:1_2|2))(?:_F|_H)?|NAN|(?:UCHAR|UINT|ULONG|USHRT)_MAX)\b/,alias:"constant"}}),E.languages.insertBefore("opencl","class-name",{"builtin-type":{pattern:/\b(?:_cl_(?:command_queue|context|device_id|event|kernel|mem|platform_id|program|sampler)|cl_(?:image_format|mem_fence_flags)|clk_event_t|event_t|image(?:1d_(?:array_|buffer_)?t|2d_(?:array_(?:depth_|msaa_depth_|msaa_)?|depth_|msaa_depth_|msaa_)?t|3d_t)|intptr_t|ndrange_t|ptrdiff_t|queue_t|reserve_id_t|sampler_t|size_t|uintptr_t)\b/,alias:"keyword"}});var _={"type-opencl-host":{pattern:/\b(?:cl_(?:GLenum|GLint|GLuin|addressing_mode|bitfield|bool|buffer_create_type|build_status|channel_(?:order|type)|(?:u?(?:char|int|long|short)|double|float)(?:2|3|4|8|16)?|command_(?:queue(?:_info|_properties)?|type)|context(?:_info|_properties)?|device_(?:exec_capabilities|fp_config|id|info|local_mem_type|mem_cache_type|type)|(?:event|sampler)(?:_info)?|filter_mode|half|image_info|kernel(?:_info|_work_group_info)?|map_flags|mem(?:_flags|_info|_object_type)?|platform_(?:id|info)|profiling_info|program(?:_build_info|_info)?))\b/,alias:"keyword"},"boolean-opencl-host":{pattern:/\bCL_(?:FALSE|TRUE)\b/,alias:"boolean"},"constant-opencl-host":{pattern:/\bCL_(?:A|ABGR|ADDRESS_(?:CLAMP(?:_TO_EDGE)?|MIRRORED_REPEAT|NONE|REPEAT)|ARGB|BGRA|BLOCKING|BUFFER_CREATE_TYPE_REGION|BUILD_(?:ERROR|IN_PROGRESS|NONE|PROGRAM_FAILURE|SUCCESS)|COMMAND_(?:ACQUIRE_GL_OBJECTS|BARRIER|COPY_(?:BUFFER(?:_RECT|_TO_IMAGE)?|IMAGE(?:_TO_BUFFER)?)|FILL_(?:BUFFER|IMAGE)|MAP(?:_BUFFER|_IMAGE)|MARKER|MIGRATE(?:_SVM)?_MEM_OBJECTS|NATIVE_KERNEL|NDRANGE_KERNEL|READ_(?:BUFFER(?:_RECT)?|IMAGE)|RELEASE_GL_OBJECTS|SVM_(?:FREE|MAP|MEMCPY|MEMFILL|UNMAP)|TASK|UNMAP_MEM_OBJECT|USER|WRITE_(?:BUFFER(?:_RECT)?|IMAGE))|COMPILER_NOT_AVAILABLE|COMPILE_PROGRAM_FAILURE|COMPLETE|CONTEXT_(?:DEVICES|INTEROP_USER_SYNC|NUM_DEVICES|PLATFORM|PROPERTIES|REFERENCE_COUNT)|DEPTH(?:_STENCIL)?|DEVICE_(?:ADDRESS_BITS|AFFINITY_DOMAIN_(?:L[1-4]_CACHE|NEXT_PARTITIONABLE|NUMA)|AVAILABLE|BUILT_IN_KERNELS|COMPILER_AVAILABLE|DOUBLE_FP_CONFIG|ENDIAN_LITTLE|ERROR_CORRECTION_SUPPORT|EXECUTION_CAPABILITIES|EXTENSIONS|GLOBAL_(?:MEM_(?:CACHELINE_SIZE|CACHE_SIZE|CACHE_TYPE|SIZE)|VARIABLE_PREFERRED_TOTAL_SIZE)|HOST_UNIFIED_MEMORY|IL_VERSION|IMAGE(?:2D_MAX_(?:HEIGHT|WIDTH)|3D_MAX_(?:DEPTH|HEIGHT|WIDTH)|_BASE_ADDRESS_ALIGNMENT|_MAX_ARRAY_SIZE|_MAX_BUFFER_SIZE|_PITCH_ALIGNMENT|_SUPPORT)|LINKER_AVAILABLE|LOCAL_MEM_SIZE|LOCAL_MEM_TYPE|MAX_(?:CLOCK_FREQUENCY|COMPUTE_UNITS|CONSTANT_ARGS|CONSTANT_BUFFER_SIZE|GLOBAL_VARIABLE_SIZE|MEM_ALLOC_SIZE|NUM_SUB_GROUPS|ON_DEVICE_(?:EVENTS|QUEUES)|PARAMETER_SIZE|PIPE_ARGS|READ_IMAGE_ARGS|READ_WRITE_IMAGE_ARGS|SAMPLERS|WORK_GROUP_SIZE|WORK_ITEM_DIMENSIONS|WORK_ITEM_SIZES|WRITE_IMAGE_ARGS)|MEM_BASE_ADDR_ALIGN|MIN_DATA_TYPE_ALIGN_SIZE|NAME|NATIVE_VECTOR_WIDTH_(?:CHAR|DOUBLE|FLOAT|HALF|INT|LONG|SHORT)|NOT_(?:AVAILABLE|FOUND)|OPENCL_C_VERSION|PARENT_DEVICE|PARTITION_(?:AFFINITY_DOMAIN|BY_AFFINITY_DOMAIN|BY_COUNTS|BY_COUNTS_LIST_END|EQUALLY|FAILED|MAX_SUB_DEVICES|PROPERTIES|TYPE)|PIPE_MAX_(?:ACTIVE_RESERVATIONS|PACKET_SIZE)|PLATFORM|PREFERRED_(?:GLOBAL_ATOMIC_ALIGNMENT|INTEROP_USER_SYNC|LOCAL_ATOMIC_ALIGNMENT|PLATFORM_ATOMIC_ALIGNMENT|VECTOR_WIDTH_(?:CHAR|DOUBLE|FLOAT|HALF|INT|LONG|SHORT))|PRINTF_BUFFER_SIZE|PROFILE|PROFILING_TIMER_RESOLUTION|QUEUE_(?:ON_(?:DEVICE_(?:MAX_SIZE|PREFERRED_SIZE|PROPERTIES)|HOST_PROPERTIES)|PROPERTIES)|REFERENCE_COUNT|SINGLE_FP_CONFIG|SUB_GROUP_INDEPENDENT_FORWARD_PROGRESS|SVM_(?:ATOMICS|CAPABILITIES|COARSE_GRAIN_BUFFER|FINE_GRAIN_BUFFER|FINE_GRAIN_SYSTEM)|TYPE(?:_ACCELERATOR|_ALL|_CPU|_CUSTOM|_DEFAULT|_GPU)?|VENDOR(?:_ID)?|VERSION)|DRIVER_VERSION|EVENT_(?:COMMAND_(?:EXECUTION_STATUS|QUEUE|TYPE)|CONTEXT|REFERENCE_COUNT)|EXEC_(?:KERNEL|NATIVE_KERNEL|STATUS_ERROR_FOR_EVENTS_IN_WAIT_LIST)|FILTER_(?:LINEAR|NEAREST)|FLOAT|FP_(?:CORRECTLY_ROUNDED_DIVIDE_SQRT|DENORM|FMA|INF_NAN|ROUND_TO_INF|ROUND_TO_NEAREST|ROUND_TO_ZERO|SOFT_FLOAT)|GLOBAL|HALF_FLOAT|IMAGE_(?:ARRAY_SIZE|BUFFER|DEPTH|ELEMENT_SIZE|FORMAT|FORMAT_MISMATCH|FORMAT_NOT_SUPPORTED|HEIGHT|NUM_MIP_LEVELS|NUM_SAMPLES|ROW_PITCH|SLICE_PITCH|WIDTH)|INTENSITY|INVALID_(?:ARG_INDEX|ARG_SIZE|ARG_VALUE|BINARY|BUFFER_SIZE|BUILD_OPTIONS|COMMAND_QUEUE|COMPILER_OPTIONS|CONTEXT|DEVICE|DEVICE_PARTITION_COUNT|DEVICE_QUEUE|DEVICE_TYPE|EVENT|EVENT_WAIT_LIST|GLOBAL_OFFSET|GLOBAL_WORK_SIZE|GL_OBJECT|HOST_PTR|IMAGE_DESCRIPTOR|IMAGE_FORMAT_DESCRIPTOR|IMAGE_SIZE|KERNEL|KERNEL_ARGS|KERNEL_DEFINITION|KERNEL_NAME|LINKER_OPTIONS|MEM_OBJECT|MIP_LEVEL|OPERATION|PIPE_SIZE|PLATFORM|PROGRAM|PROGRAM_EXECUTABLE|PROPERTY|QUEUE_PROPERTIES|SAMPLER|VALUE|WORK_DIMENSION|WORK_GROUP_SIZE|WORK_ITEM_SIZE)|KERNEL_(?:ARG_(?:ACCESS_(?:NONE|QUALIFIER|READ_ONLY|READ_WRITE|WRITE_ONLY)|ADDRESS_(?:CONSTANT|GLOBAL|LOCAL|PRIVATE|QUALIFIER)|INFO_NOT_AVAILABLE|NAME|TYPE_(?:CONST|NAME|NONE|PIPE|QUALIFIER|RESTRICT|VOLATILE))|ATTRIBUTES|COMPILE_NUM_SUB_GROUPS|COMPILE_WORK_GROUP_SIZE|CONTEXT|EXEC_INFO_SVM_FINE_GRAIN_SYSTEM|EXEC_INFO_SVM_PTRS|FUNCTION_NAME|GLOBAL_WORK_SIZE|LOCAL_MEM_SIZE|LOCAL_SIZE_FOR_SUB_GROUP_COUNT|MAX_NUM_SUB_GROUPS|MAX_SUB_GROUP_SIZE_FOR_NDRANGE|NUM_ARGS|PREFERRED_WORK_GROUP_SIZE_MULTIPLE|PRIVATE_MEM_SIZE|PROGRAM|REFERENCE_COUNT|SUB_GROUP_COUNT_FOR_NDRANGE|WORK_GROUP_SIZE)|LINKER_NOT_AVAILABLE|LINK_PROGRAM_FAILURE|LOCAL|LUMINANCE|MAP_(?:FAILURE|READ|WRITE|WRITE_INVALIDATE_REGION)|MEM_(?:ALLOC_HOST_PTR|ASSOCIATED_MEMOBJECT|CONTEXT|COPY_HOST_PTR|COPY_OVERLAP|FLAGS|HOST_NO_ACCESS|HOST_PTR|HOST_READ_ONLY|HOST_WRITE_ONLY|KERNEL_READ_AND_WRITE|MAP_COUNT|OBJECT_(?:ALLOCATION_FAILURE|BUFFER|IMAGE1D|IMAGE1D_ARRAY|IMAGE1D_BUFFER|IMAGE2D|IMAGE2D_ARRAY|IMAGE3D|PIPE)|OFFSET|READ_ONLY|READ_WRITE|REFERENCE_COUNT|SIZE|SVM_ATOMICS|SVM_FINE_GRAIN_BUFFER|TYPE|USES_SVM_POINTER|USE_HOST_PTR|WRITE_ONLY)|MIGRATE_MEM_OBJECT_(?:CONTENT_UNDEFINED|HOST)|MISALIGNED_SUB_BUFFER_OFFSET|NONE|NON_BLOCKING|OUT_OF_(?:HOST_MEMORY|RESOURCES)|PIPE_(?:MAX_PACKETS|PACKET_SIZE)|PLATFORM_(?:EXTENSIONS|HOST_TIMER_RESOLUTION|NAME|PROFILE|VENDOR|VERSION)|PROFILING_(?:COMMAND_(?:COMPLETE|END|QUEUED|START|SUBMIT)|INFO_NOT_AVAILABLE)|PROGRAM_(?:BINARIES|BINARY_SIZES|BINARY_TYPE(?:_COMPILED_OBJECT|_EXECUTABLE|_LIBRARY|_NONE)?|BUILD_(?:GLOBAL_VARIABLE_TOTAL_SIZE|LOG|OPTIONS|STATUS)|CONTEXT|DEVICES|IL|KERNEL_NAMES|NUM_DEVICES|NUM_KERNELS|REFERENCE_COUNT|SOURCE)|QUEUED|QUEUE_(?:CONTEXT|DEVICE|DEVICE_DEFAULT|ON_DEVICE|ON_DEVICE_DEFAULT|OUT_OF_ORDER_EXEC_MODE_ENABLE|PROFILING_ENABLE|PROPERTIES|REFERENCE_COUNT|SIZE)|R|RA|READ_(?:ONLY|WRITE)_CACHE|RG|RGB|RGBA|RGBx|RGx|RUNNING|Rx|SAMPLER_(?:ADDRESSING_MODE|CONTEXT|FILTER_MODE|LOD_MAX|LOD_MIN|MIP_FILTER_MODE|NORMALIZED_COORDS|REFERENCE_COUNT)|(?:UN)?SIGNED_INT(?:8|16|32)|SNORM_INT(?:8|16)|SUBMITTED|SUCCESS|UNORM_INT(?:8|16|24|_101010|_101010_2)|UNORM_SHORT_(?:555|565)|VERSION_(?:1_0|1_1|1_2|2_0|2_1)|sBGRA|sRGB|sRGBA|sRGBx)\b/,alias:"constant"},"function-opencl-host":{pattern:/\bcl(?:BuildProgram|CloneKernel|CompileProgram|Create(?:Buffer|CommandQueue(?:WithProperties)?|Context|ContextFromType|Image|Image2D|Image3D|Kernel|KernelsInProgram|Pipe|ProgramWith(?:Binary|BuiltInKernels|IL|Source)|Sampler|SamplerWithProperties|SubBuffer|SubDevices|UserEvent)|Enqueue(?:(?:Barrier|Marker)(?:WithWaitList)?|Copy(?:Buffer(?:Rect|ToImage)?|Image(?:ToBuffer)?)|(?:Fill|Map)(?:Buffer|Image)|MigrateMemObjects|NDRangeKernel|NativeKernel|(?:Read|Write)(?:Buffer(?:Rect)?|Image)|SVM(?:Free|Map|MemFill|Memcpy|MigrateMem|Unmap)|Task|UnmapMemObject|WaitForEvents)|Finish|Flush|Get(?:CommandQueueInfo|ContextInfo|Device(?:AndHostTimer|IDs|Info)|Event(?:Profiling)?Info|ExtensionFunctionAddress(?:ForPlatform)?|HostTimer|ImageInfo|Kernel(?:ArgInfo|Info|SubGroupInfo|WorkGroupInfo)|MemObjectInfo|PipeInfo|Platform(?:IDs|Info)|Program(?:Build)?Info|SamplerInfo|SupportedImageFormats)|LinkProgram|(?:Release|Retain)(?:CommandQueue|Context|Device|Event|Kernel|MemObject|Program|Sampler)|SVM(?:Alloc|Free)|Set(?:CommandQueueProperty|DefaultDeviceCommandQueue|EventCallback|Kernel|Kernel(?:Arg(?:SVMPointer)?|ExecInfo)|MemObjectDestructorCallback|UserEventStatus)|Unload(?:Platform)?Compiler|WaitForEvents)\b/,alias:"function"}};E.languages.insertBefore("c","keyword",_),E.languages.cpp&&(_["type-opencl-host-cpp"]={pattern:/\b(?:Buffer|BufferGL|BufferRenderGL|CommandQueue|Context|Device|DeviceCommandQueue|EnqueueArgs|Event|Image|Image1D|Image1DArray|Image1DBuffer|Image2D|Image2DArray|Image2DGL|Image3D|Image3DGL|ImageFormat|ImageGL|Kernel|KernelFunctor|LocalSpaceArg|Memory|NDRange|Pipe|Platform|Program|SVMAllocator|SVMTraitAtomic|SVMTraitCoarse|SVMTraitFine|SVMTraitReadOnly|SVMTraitReadWrite|SVMTraitWriteOnly|Sampler|UserEvent)\b/,alias:"keyword"},E.languages.insertBefore("cpp","keyword",_))}(E)}E.exports=R,R.displayName="opencl",R.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3879.17f211ad.chunk.js b/ydb/core/viewer/monitoring/static/js/3879.17f211ad.chunk.js deleted file mode 100644 index f4cc5534a477..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3879.17f211ad.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3879],{73879:function(e,a,d){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var d=a(e),_={name:"nl",weekdays:"zondag_maandag_dinsdag_woensdag_donderdag_vrijdag_zaterdag".split("_"),weekdaysShort:"zo._ma._di._wo._do._vr._za.".split("_"),weekdaysMin:"zo_ma_di_wo_do_vr_za".split("_"),months:"januari_februari_maart_april_mei_juni_juli_augustus_september_oktober_november_december".split("_"),monthsShort:"jan_feb_mrt_apr_mei_jun_jul_aug_sep_okt_nov_dec".split("_"),ordinal:function(e){return"["+e+(1===e||8===e||e>=20?"ste":"de")+"]"},weekStart:1,yearStart:4,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD-MM-YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"over %s",past:"%s geleden",s:"een paar seconden",m:"een minuut",mm:"%d minuten",h:"een uur",hh:"%d uur",d:"een dag",dd:"%d dagen",M:"een maand",MM:"%d maanden",y:"een jaar",yy:"%d jaar"}};return d.default.locale(_,null,!0),_}(d(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3940.f5079e40.chunk.js b/ydb/core/viewer/monitoring/static/js/3940.f5079e40.chunk.js deleted file mode 100644 index 56b8b6fd75f9..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3940.f5079e40.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3940],{8873:(e,t,n)=>{n.d(t,{A:()=>i});var o=n(59284);const i=e=>o.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),o.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 0 1 6.445 5.649.75.75 0 1 1-1.488.194A5.001 5.001 0 0 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 1 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5m5.25 13a.75.75 0 0 0 .75-.75v-3a.75.75 0 0 0-.75-.75h-3a.75.75 0 1 0 0 1.5h1.32a5.001 5.001 0 0 1-8.528-2.843.75.75 0 1 0-1.487.194 6.501 6.501 0 0 0 10.945 3.84v1.059c0 .414.336.75.75.75",clipRule:"evenodd"}))},25569:(e,t,n)=>{n.d(t,{A:()=>i});var o=n(59284);const i=e=>o.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),o.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.488 3.43a.75.75 0 0 1 .081 1.058l-6 7a.75.75 0 0 1-1.1.042l-3.5-3.5A.75.75 0 0 1 4.03 6.97l2.928 2.927 5.473-6.385a.75.75 0 0 1 1.057-.081",clipRule:"evenodd"}))},69024:(e,t,n)=>{n.d(t,{a:()=>s,j:()=>i});var o=n(59284);function i(e,t){return e.map((e=>{var n;let o;e.sub&&(o=i(e.sub,t));const s=null!==(n=t[e.name])&&void 0!==n?n:e.width;return Object.assign(Object.assign({},e),{width:s,sub:o})}))}function s({saveSizes:e,getSizes:t}){const[n,i]=o.useState((()=>t()));return[n,o.useCallback(((t,n)=>{i((o=>{const i=Object.assign(Object.assign({},o),{[t]:n});return e(i),i}))}),[e])]}},24555:(e,t,n)=>{n.d(t,{l:()=>te});var o=n(59284),i=n(359),s=n(85736),r=n(32084),l=n(27145),a=n(92609);var c=n(90826),u=n(51301),d=n(63246),h=n(34379),p=n(46819),v=n(28664),m=n(69220),f=n(56353),b=n(89226);const g=(0,m.om)("select-filter"),C={padding:"4px 4px 0"},E=o.forwardRef(((e,t)=>{const{onChange:n,onKeyDown:i,renderFilter:s,size:r,value:l,placeholder:a,popupId:c,activeIndex:u}=e,d=o.useRef(null);o.useImperativeHandle(t,(()=>({focus:()=>{var e;return null===(e=d.current)||void 0===e?void 0:e.focus({preventScroll:!0})}})),[]);const h={value:l,placeholder:a,size:1,onKeyDown:i,onChange:e=>{n(e.target.value)},"aria-label":(0,b.A)("label_filter"),"aria-controls":c,"aria-activedescendant":void 0===u?void 0:`${c}-item-${u}`};return s?s({onChange:n,onKeyDown:i,value:l,ref:d,style:C,inputProps:h}):o.createElement("div",{className:g(),style:C},o.createElement(v.k,{controlRef:d,controlProps:{className:g("input"),size:1,"aria-label":h["aria-label"],"aria-controls":h["aria-controls"],"aria-activedescendant":h["aria-activedescendant"]},size:r,value:l,placeholder:a,onUpdate:n,onKeyDown:i,qa:f.pn.FILTER_INPUT}))}));E.displayName="SelectFilter";var w=n(40091);const T=e=>Boolean(e&&"label"in e),S=e=>{const{getOptionHeight:t,getOptionGroupHeight:n,size:o,option:i,index:s,mobile:r}=e;let l=r?f.t5:f.KK[o];if(T(i)){const e=0===s?0:f.Vm;return l=""===i.label?0:l,n?n(i,s):l+e}return t?t(i,s):l},y=e=>"string"===typeof e.content?e.content:"string"===typeof e.children?e.children:e.text?e.text:e.value,O=e=>(e=>o.Children.toArray(e))(e).reduce(((e,{props:t})=>{if("label"in t){const n=t.options||(e=>o.Children.toArray(e).reduce(((e,{props:t})=>("value"in t&&e.push(t),e)),[]))(t.children);e.push({options:n,label:t.label})}return"value"in t&&e.push(Object.assign({},t)),e}),[]),R=(e,t)=>t?t.findIndex((t=>{if(T(t))return!1;if(t.disabled)return!1;const n=y(t);return(o=e,new RegExp(o.replace(/[-/\\^$*+?.()|[\]{}]/g,"\\$&"),"i")).test(n);var o})):-1,A=e=>{var t;return(null===(t=null===e||void 0===e?void 0:e.current)||void 0===t?void 0:t.getItems())||[]},x=e=>{const{options:t,filter:n,filterOption:o}=e,i=t.filter((e=>!!T(e)||(o?o(e,n):((e,t)=>{const n=y(e).toLocaleLowerCase(),o=t.toLocaleLowerCase();return-1!==n.indexOf(o)})(e,n))));return i.reduce(((e,t,n)=>{const o=T(t),s=T(e[e.length-1]),r=n===i.length-1;return o&&s&&e.pop(),(!o||o&&!r)&&e.push(t),e}),[])};function N(e){const t=e.offsetParent;if(t instanceof HTMLElement){const n=t.offsetHeight,o=t.scrollTop,i=e.offsetTop;i+e.offsetHeight>=o+n?t.scrollTo({top:i-n+e.offsetHeight}):i<=o&&t.scrollTo({top:i})}return!0}const H=(0,m.om)("select-list"),k=({option:e,renderOptionGroup:t})=>t?o.createElement("div",{className:H("group-label-custom")},t(e)):o.createElement("div",{className:H("group-label",{empty:""===e.label})},o.createElement("div",{className:H("group-label-content")},e.label));var z=n(25569),I=n(99991);const P=(0,m.om)("select-list"),L=({option:e})=>{const{content:t,children:n,disabled:i,title:s}=e;return o.createElement("span",{title:s,className:P("option-default-label",{disabled:i})},t||n)},M=e=>{const{renderOption:t,value:n,option:i,multiple:s}=e,r=-1!==n.indexOf(i.value),l=t?t(i):o.createElement(L,{option:i});return o.createElement("div",{"data-qa":i.qa,className:P("option",{colored:r&&!s,disabled:i.disabled})},s&&o.createElement(I.I,{className:P("tick-icon",{shown:r&&s}),data:z.A}),l)};var B=n(29322),D=n(74417);const F=e=>{const t=o.useRef(null);return(0,B.v)({element:t.current,onIntersect:null===e||void 0===e?void 0:e.onIntersect}),o.createElement("div",{ref:t,className:(0,f.C1)("loading-indicator")},o.createElement(D.a,null))},W={value:"__SELECT_LIST_ITEM_LOADING__",disabled:!0},j=o.forwardRef(((e,t)=>{const{onOptionClick:n,renderOption:i,renderOptionGroup:s,getOptionHeight:r,getOptionGroupHeight:l,size:a,flattenOptions:c,value:u,multiple:d,virtualized:h,mobile:p,loading:v,onLoadMore:m,id:b,activeIndex:g,onChangeActive:C}=e,E=o.useMemo((()=>v?[...c,W]:c),[c,v]),T=o.useMemo((()=>c.reduce(((e,t,n)=>("value"in t&&u.includes(t.value)&&e.push(n),e)),[])),[c,u]),y=(e=>{const{getOptionHeight:t,getOptionGroupHeight:n,size:o,options:i,mobile:s}=e;return i.reduce(((e,i,r)=>e+S({getOptionHeight:t,getOptionGroupHeight:n,size:o,option:i,index:r,mobile:s})),0)})({options:E,getOptionHeight:r,getOptionGroupHeight:l,size:a,mobile:p}),O=o.useCallback(((e,t)=>S({getOptionHeight:r,getOptionGroupHeight:l,size:a,option:e,index:t,mobile:p})),[r,l,p,a]),R=o.useCallback(((e,t,n)=>{if("label"in e){const t=s?e=>s(e,{itemHeight:O(e,n)}):void 0;return o.createElement(k,{option:e,renderOptionGroup:t})}if(e.value===W.value)return o.createElement(F,{onIntersect:0===n?void 0:m});const r=i?e=>i(e,{itemHeight:O(e,n)}):void 0;return o.createElement(M,{option:e,value:u,multiple:d,renderOption:r})}),[i,s,u,d,O,m]);return o.createElement(w.B,{ref:t,className:(0,f.C1)({size:a,virtualized:h,mobile:p}),qa:f.pn.LIST,itemClassName:(0,f.C1)("item"),itemHeight:O,itemsHeight:h?y:void 0,items:E,filterable:!1,virtualized:h,renderItem:R,onItemClick:n,selectedItemIndex:T,id:b,role:"listbox",activeItemIndex:g,onChangeActive:C,deactivateOnLeave:!1,onScrollToItem:N})}));j.displayName="SelectList";const Y=(0,m.om)("select-empty-placeholder"),_=({renderEmptyOptions:e,filter:t})=>o.createElement("div",{className:Y({empty:!e})},null===e||void 0===e?void 0:e({filter:t}));var $=n(19884),V=n(93628),q=n(794);function G(e){const{name:t,value:n,disabled:i,form:s,onReset:r}=e,l=(0,q.d)({onReset:r,initialValue:n});return!t||i?null:0===n.length?o.createElement("input",{ref:l,type:"hidden",name:t,value:n,form:s,disabled:i}):o.createElement(o.Fragment,null,n.map(((e,n)=>o.createElement("input",{key:e,ref:0===n?l:void 0,value:e,type:"hidden",name:t,form:s,disabled:i}))))}const K=e=>{const{onChange:t,open:n,disabled:s}=e,[r,l]=o.useState(""),[a,c]=o.useState(),u=o.useCallback((e=>{if(clearTimeout(a),e){const e=window.setTimeout((()=>l("")),f.FY);c(e)}}),[a]),d=o.useCallback((e=>{e.stopPropagation();const t=((e,t)=>{const n=1===e.length;let o="";return e===i.D.BACKSPACE&&t.length?o=t.slice(0,t.length-1):n&&(o=(t+e).trim()),o})(e.key,r);r!==t&&(u(t),l(t))}),[u,r]);o.useEffect((()=>(n&&!s?document.addEventListener("keydown",d):n||s||l(""),()=>{n&&!s&&document.removeEventListener("keydown",d)})),[d,n,s]),o.useEffect((()=>(n||clearTimeout(a),()=>clearTimeout(a))),[n,a]),o.useEffect((()=>{t(r)}),[t,r])};function U(e,t){let n=-1;return t.length>0&&(n=e.findIndex((e=>"value"in e&&t.includes(e.value)&&!e.disabled))),-1===n&&(n=e.findIndex((e=>"value"in e&&!e.disabled))),-1===n?void 0:n}var J=n(87924),Z=n.n(J);function X(e){return Z()(e,[f.zJ])}function Q(e){const{filter:t="",filterable:n,filterOption:i}=e,s=o.useMemo((()=>X(e.options)?e.options:(e=>{const t=e.reduce(((e,t)=>("label"in t?(e.push({label:t.label,disabled:!0,data:t.data}),e.push(...t.options||[])):e.push(t),e)),[]);return Object.defineProperty(t,f.zJ,{enumerable:!1,value:{}}),t})(e.options)),[e.options]),r=o.useMemo((()=>n?x({options:s,filter:t,filterOption:i}):s),[t,n,i,s]);return s[f.zJ].filteredOptions=r,s}const ee=({renderFilter:e,renderList:t})=>o.createElement(o.Fragment,null,e(),t()),te=o.forwardRef((function(e,t){const{onUpdate:n,onOpenChange:v,onFilterChange:m,renderControl:b,renderFilter:g,renderOption:C,renderOptionGroup:w,renderSelectedOption:S,renderEmptyOptions:x,renderPopup:N=ee,getOptionHeight:H,getOptionGroupHeight:k,filterOption:z,name:I,form:P,className:L,controlClassName:M,popupClassName:B,qa:D,value:F,defaultValue:W,defaultOpen:Y,open:q,label:J,placeholder:te,filterPlaceholder:ne,width:oe,popupWidth:ie,popupPlacement:se,error:re,virtualizationThreshold:le=f.Us,view:ae="normal",size:ce="m",pin:ue="round-round",multiple:de=!1,disabled:he=!1,filterable:pe=!1,filter:ve,disablePortal:me,hasClear:fe=!1,onClose:be,id:ge,hasCounter:Ce,renderCounter:Ee,title:we}=e,Te=(0,p.I)(),[Se,ye]=(0,s.P)(ve,"",m),Oe=o.useRef(null),Re=o.useRef(null),Ae=o.useRef(null),xe=o.useRef(null),Ne=(0,r.N)(t,Re),{value:He,open:ke,toggleOpen:ze,setValue:Ie,handleSelection:Pe,handleClearValue:Le}=(({defaultOpen:e,onClose:t,onOpenChange:n,open:i,value:r,defaultValue:c=[],multiple:u,onUpdate:d,disabled:h})=>{const[p,v]=(0,s.P)(r,c,d),[m,f]=o.useState(),b=(0,a.F)({defaultOpen:e,onClose:t,onOpenChange:n,open:i}),{toggleOpen:g}=b,C=(0,l.Tt)(b,["toggleOpen"]),E=o.useCallback((e=>{h||v(e)}),[v,h]),w=o.useCallback((e=>{if(!p.includes(e.value)){const t=[e.value];E(t)}g(!1)}),[p,E,g]),T=o.useCallback((e=>{const t=p.includes(e.value)?p.filter((t=>t!==e.value)):[...p,e.value];E(t)}),[p,E]),S=o.useCallback((e=>{u?T(e):w(e)}),[u,w,T]),y=o.useCallback((()=>{E([])}),[E]);return Object.assign({value:p,activeIndex:m,setValue:E,handleSelection:S,handleClearValue:y,toggleOpen:g,setActiveIndex:f},C)})({onUpdate:n,value:F,defaultValue:W,defaultOpen:Y,multiple:de,open:q,onClose:be,onOpenChange:v,disabled:he});o.useEffect((()=>{!ke&&pe&&Te&&setTimeout((()=>{ye("")}),300)}),[ke,pe,ye,Te]);const Me=Q({options:e.options||O(e.children),filter:Se,filterable:pe,filterOption:z}),Be=function(e){if(!X(e))throw Error("You should use options generated by useSelectOptions hook");return Z()(e,[f.zJ,"filteredOptions"])}(Me),De=((e,t,n)=>{if(0===t.length)return null;const i=e.filter((e=>!T(e))),s=t.reduce(((e,t)=>{const n=i.find((e=>e.value===t));return e.push(n||{value:t}),e}),[]);return n?s.map(((e,t)=>o.createElement(o.Fragment,{key:e.value},n(e,t)))):s.map((e=>y(e))).join(", ")})(Me,He,S),Fe=Be.length>=le,{errorMessage:We,errorPlacement:je,validationState:Ye}=(0,h.Av)({error:re,errorMessage:e.errorMessage,errorPlacement:e.errorPlacement||"outside",validationState:e.validationState}),_e=(0,c.u)(),$e="invalid"===Ye,Ve=$e&&Boolean(We)&&"outside"===je,qe=$e&&Boolean(We)&&"inside"===je,Ge=o.useCallback((e=>{var t,n;if(e&&!(null===e||void 0===e?void 0:e.disabled)&&!("label"in e)){if(de){const e=null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t?void 0:t.getActiveItem();null===(n=Ae.current)||void 0===n||n.focus(),"number"===typeof e&&setTimeout((()=>{var t;null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.activateItem(e,!0)}),50)}Pe(e)}}),[Pe,de]),Ke=o.useCallback((e=>{var t;[i.D.ENTER,i.D.SPACEBAR].includes(e.key)&&ke&&(e.preventDefault(),e.key===i.D.SPACEBAR&&Ge((e=>{var t;const n=A(e),o=null===(t=null===e||void 0===e?void 0:e.current)||void 0===t?void 0:t.getActiveItem();return"number"===typeof o?n[o]:void 0})(xe))),[i.D.ARROW_DOWN,i.D.ARROW_UP].includes(e.key)&&!ke&&(e.preventDefault(),ze()),null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.onKeyDown(e)}),[Ge,ke,ze]),Ue=o.useCallback((e=>{var t;null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.onKeyDown(e)}),[]),Je=o.useCallback((e=>{var t;if(e){const n=R(e,A(xe));"number"===typeof n&&-1!==n&&(null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.activateItem(n,!0))}}),[]);K({onChange:Je,open:ke,disabled:pe}),o.useEffect((()=>{var e;ke&&pe&&(null===(e=Ae.current)||void 0===e||e.focus())}),[ke,pe]);const Ze=Object.assign({},"max"===oe&&{width:oe}),Xe={};"number"===typeof oe&&(Xe.width=oe);const Qe=o.useCallback((()=>ze(!1)),[ze]),{onFocus:et,onBlur:tt}=e,{focusWithinProps:nt}=(0,u.R)({onFocusWithin:et,onBlurWithin:o.useCallback((e=>{null===tt||void 0===tt||tt(e),Qe()}),[Qe,tt])}),ot=(0,c.u)(),it=null!==ge&&void 0!==ge?ge:ot,st=`select-popup-${it}`,[rt,lt]=function({options:e,value:t,open:n}){const[i,s]=o.useState((()=>{if(n)return U(e,t)})),[r,l]=o.useState(n);return r!==n&&(l(n),n&&s(U(e,t))),[n&&void 0!==i&&i{ye("")}:void 0},N({renderFilter:()=>pe?o.createElement(E,{ref:Ae,size:ce,value:Se,placeholder:ne,onChange:ye,onKeyDown:Ue,renderFilter:g,popupId:st,activeIndex:rt}):null,renderList:()=>Be.length||e.loading?o.createElement(j,{ref:xe,size:ce,value:He,mobile:Te,flattenOptions:Be,multiple:de,virtualized:Fe,onOptionClick:Ge,renderOption:C,renderOptionGroup:w,getOptionHeight:H,getOptionGroupHeight:k,loading:e.loading,onLoadMore:e.onLoadMore,id:st,activeIndex:rt,onChangeActive:lt}):o.createElement(_,{filter:Se,renderEmptyOptions:x})})),o.createElement(d.o,{errorMessage:Ve?We:null,errorMessageId:_e}),o.createElement(G,{name:I,value:He,disabled:he,form:P,onReset:Ie}))}));te.Option=e=>null,te.OptionGroup=e=>null},19884:(e,t,n)=>{n.d(t,{Y:()=>g});var o=n(59284),i=n(94420),s=n(13066),r=n(905),l=n.n(r),a=n(90826),c=n(99991),u=n(84375),d=n(56353),h=n(89226),p=n(81240);const v=e=>{const{size:t,onClick:n,onMouseEnter:i,onMouseLeave:s,renderIcon:r}=e,l=r?r():o.createElement(c.I,{className:(0,d.Di)("clear"),data:p.A});return o.createElement("button",{className:(0,d.Di)({size:t}),"aria-label":(0,h.A)("label_clear"),onClick:n,onMouseEnter:i,onMouseLeave:s,"data-qa":d.pn.CLEAR,type:"button"},l)};v.displayName="SelectClear";var m=n(98089);const f=(0,n(69220).om)("select-counter");function b({count:e,size:t,disabled:n}){return o.createElement("div",{className:f({size:t})},o.createElement(m.E,{variant:"xl"===t?"body-2":"body-1",color:n?"hint":"primary",className:f("text")},e))}const g=o.forwardRef(((e,t)=>{const{toggleOpen:n,clearValue:r,onKeyDown:p,renderControl:m,view:f,size:g,pin:C,selectedOptionsContent:E,className:w,qa:T,label:S,placeholder:y,isErrorVisible:O,errorMessage:R,open:A,disabled:x,value:N,hasClear:H,popupId:k,selectId:z,activeIndex:I,renderCounter:P,hasCounter:L,title:M}=e,B=Boolean(E),D=Boolean(y&&!B),F=Array.isArray(N)&&!l()(N.filter(Boolean)),W=(0,a.u)(),[j,Y]=o.useState(!1),_={open:A,size:g,pin:C,disabled:x,error:O,"has-clear":H,"no-active":j,"has-value":F},$={open:A,size:g,view:f,pin:C,disabled:x,error:O},V=o.useCallback((e=>{e&&e.currentTarget!==document.activeElement&&"focus"in e.currentTarget&&e.currentTarget.focus(),n()}),[n]),q=o.useCallback((()=>{Y(!0)}),[]),G=o.useCallback((()=>{Y(!1)}),[]),K=o.useCallback((()=>{Y(!1),r()}),[r]),U=()=>{if(!L)return null;const e=N.length,t=o.createElement(b,{count:e,size:g,disabled:x});return P?P(t,{count:e,size:g,disabled:x}):t},J=e=>{const t=0===N.length;return!H||t||x?null:o.createElement(v,{size:g,onClick:K,onMouseEnter:q,onMouseLeave:G,renderIcon:e.renderIcon})},Z={id:z,role:"combobox","aria-controls":A?k:void 0,"aria-haspopup":"listbox","aria-expanded":A,"aria-activedescendant":void 0===I?void 0:`${k}-item-${I}`,onClick:V,onKeyDown:p,disabled:x};return m?m({onKeyDown:p,onClear:r,onClick:V,renderClear:J,renderCounter:U,ref:t,open:A,popupId:k,selectId:z,activeIndex:I,disabled:x,triggerProps:Z},{value:N}):o.createElement(o.Fragment,null,o.createElement("div",{className:(0,d.ji)(_),role:"group"},o.createElement("button",Object.assign({ref:t,className:(0,d.Zz)($,w),type:"button","data-qa":T,title:M,tabIndex:0},Z),S&&o.createElement("span",{className:(0,d.ji)("label")},S),D&&o.createElement("span",{className:(0,d.ji)("placeholder")},y),B&&o.createElement("span",{className:(0,d.ji)("option-text")},E)),U(),J({}),R&&o.createElement(u.A,{content:R,tooltipId:W},o.createElement("button",{"aria-label":(0,h.A)("label_show-error-info"),"aria-describedby":W,className:(0,d.ji)("error-icon")},o.createElement(c.I,{data:i.A,size:"s"===g?12:16}))),o.createElement(c.I,{className:(0,d.ji)("chevron-icon",{disabled:x}),data:s.A,"aria-hidden":"true"})))}));g.displayName="SelectControl"},93628:(e,t,n)=>{n.d(t,{t:()=>p});var o=n(59284),i=n(39238),s=n(12640),r=n(69220),l=n(56353);const a=e=>e-2*l.gP,c=(e,t,n)=>{let o=t;return o="number"===typeof e?e:"fit"===e?a(t):((e,t)=>t?e>l.Eq?e:l.Eq:a(e))(t,n),`${o}px`},u=e=>{const{width:t,disablePortal:n,virtualized:o}=e;return[{name:"sameWidth",enabled:!0,phase:"beforeWrite",requires:["computeStyles"],fn:({state:e,name:n})=>{var i;if(null===(i=e.modifiersData[`${n}#persistent`])||void 0===i?void 0:i.skip)return;const s=c(t,e.rects.reference.width,o);"number"!==typeof t&&"fit"!==t?(e.styles.popper.minWidth=s,e.styles.popper.width=void 0):(e.styles.popper.minWidth=s,e.styles.popper.width=s),e.styles.popper.maxWidth=`max(90vw, ${a(e.rects.reference.width)}px)`,e.modifiersData[`${n}#persistent`]={skip:"number"!==typeof t}},effect:({state:e,name:n})=>{var i;if(null===(i=e.modifiersData[`${n}#persistent`])||void 0===i?void 0:i.skip)return;const s=c(t,e.elements.reference.offsetWidth,o);"number"!==typeof t&&"fit"!==t?e.elements.popper.style.minWidth=s:(e.elements.popper.style.minWidth=s,e.elements.popper.style.width=s),e.elements.popper.style.maxWidth=`max(90vw, ${e.elements.reference.offsetWidth}px)`}},{name:"preventOverflow",options:{padding:10,altBoundary:n,altAxis:!0}}]},d=(0,r.om)("select-popup"),h=["bottom-start","bottom-end","top-start","top-end"],p=o.forwardRef((({handleClose:e,onAfterClose:t,width:n,open:r,placement:a=h,controlRef:c,children:p,className:v,disablePortal:m,virtualized:f,mobile:b,id:g},C)=>b?o.createElement(s.c,{qa:l.pn.SHEET,className:v,visible:Boolean(r),onClose:e},p):o.createElement(i.z,{contentClassName:d(null,v),qa:l.pn.POPUP,anchorRef:C,placement:a,offset:[l.gP,l.gP],open:r,onClose:e,disablePortal:m,restoreFocus:!0,restoreFocusRef:c,modifiers:u({width:n,disablePortal:m,virtualized:f}),id:g,onTransitionExited:t},p)));p.displayName="SelectPopup"},56353:(e,t,n)=>{n.d(t,{C1:()=>l,Di:()=>a,Eq:()=>p,FY:()=>v,KK:()=>c,Us:()=>m,Vm:()=>d,Zz:()=>r,gP:()=>h,gm:()=>i,ji:()=>s,pn:()=>f,t5:()=>u,zJ:()=>b});var o=n(69220);const i=(0,o.om)("select"),s=(0,o.om)("select-control"),r=(0,o.om)("select-control__button"),l=(0,o.om)("select-list"),a=(0,o.om)("select-clear"),c={s:28,m:28,l:32,xl:36},u=32,d=5,h=1,p=100,v=2e3,m=50,f={LIST:"select-list",POPUP:"select-popup",SHEET:"select-sheet",CLEAR:"select-clear",FILTER_INPUT:"select-filter-input"},b=Symbol("flatten")},89226:(e,t,n)=>{n.d(t,{A:()=>r});var o=n(72837);const i=JSON.parse('{"label_clear":"Clear","label_show-error-info":"Show popup with error info","label_filter":"Filter"}'),s=JSON.parse('{"label_clear":"\u041e\u0447\u0438\u0441\u0442\u0438\u0442\u044c","label_show-error-info":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043f\u043e\u043f\u0430\u043f \u0441 \u0438\u043d\u0444\u043e\u0440\u043c\u0430\u0446\u0435\u0439 \u043e\u0431 \u043e\u0448\u0438\u0431\u043a\u0435","label_filter":"\u0424\u0438\u043b\u044c\u0442\u0440"}'),r=(0,o.N)({en:i,ru:s},"Select")},12640:(e,t,n)=>{n.d(t,{c:()=>m});var o=n(59284),i=n(14794),s=n(98392),r=n(27145),l=n(67459);var a=n(11507);const c=(0,n(69220).om)("sheet");class u{constructor(e,t){this.x=e,this.y=t,this.timeStamp=Date.now()}}class d{constructor(e=5){this.points=[],this.pointsLen=e,this.clear()}clear(){this.points=new Array(this.pointsLen)}addMovement({x:e,y:t}){this.points.pop(),this.points.unshift(new u(e,t))}getYAcceleration(e=1){const t=this.points[0],n=this.points[e];return t&&n?(t.y-n.y)/Math.pow(t.timeStamp-n.timeStamp,2):0}}let h=[];class p extends o.Component{constructor(){super(...arguments),this.veilRef=o.createRef(),this.sheetRef=o.createRef(),this.sheetTopRef=o.createRef(),this.sheetContentBoxRef=o.createRef(),this.sheetScrollContainerRef=o.createRef(),this.velocityTracker=new d,this.observer=null,this.resizeWindowTimer=null,this.state={startScrollTop:0,startY:0,deltaY:0,prevSheetHeight:0,swipeAreaTouched:!1,contentTouched:!1,veilTouched:!1,isAnimating:!1,inWindowResizeScope:!1},this.setStyles=({status:e,deltaHeight:t=0})=>{if(!this.sheetRef.current||!this.veilRef.current)return;const n=this.sheetHeight-t,o="showing"===e?`translate3d(0, -${n}px, 0)`:"translate3d(0, 0, 0)";let i=0;"showing"===e&&(i=0===t?1:n/this.sheetHeight),this.veilRef.current.style.opacity=String(i),this.sheetRef.current.style.transform=o},this.getAvailableContentHeight=e=>{const t=.9*window.innerHeight-this.sheetTopHeight;return e>=t?t:e},this.show=()=>{this.setState({isAnimating:!0},(()=>{this.setStyles({status:"showing"}),this.setHash()}))},this.hide=()=>{this.setState({isAnimating:!0},(()=>{this.setStyles({status:"hiding"}),this.removeHash()}))},this.onSwipeAreaTouchStart=e=>{this.velocityTracker.clear(),this.setState({startY:e.nativeEvent.touches[0].clientY,swipeAreaTouched:!0})},this.onContentTouchStart=e=>{this.props.allowHideOnContentScroll&&!this.state.swipeAreaTouched&&(this.velocityTracker.clear(),this.setState({startY:e.nativeEvent.touches[0].clientY,startScrollTop:this.sheetScrollTop,contentTouched:!0}))},this.onSwipeAriaTouchMove=e=>{const t=e.nativeEvent.touches[0].clientY-this.state.startY;this.velocityTracker.addMovement({x:e.nativeEvent.touches[0].clientX,y:e.nativeEvent.touches[0].clientY}),this.setState({deltaY:t}),t<=0||this.setStyles({status:"showing",deltaHeight:t})},this.onContentTouchMove=e=>{if(!this.props.allowHideOnContentScroll)return;if(!this.state.startY)return void this.onContentTouchStart(e);const{startScrollTop:t,swipeAreaTouched:n}=this.state;if(n||this.sheetScrollTop>0||t>0&&t!==this.sheetScrollTop)return;const o=e.nativeEvent.touches[0].clientY-this.state.startY;this.velocityTracker.addMovement({x:e.nativeEvent.touches[0].clientX,y:e.nativeEvent.touches[0].clientY}),this.setState({deltaY:o}),o<=0||this.setStyles({status:"showing",deltaHeight:o})},this.onTouchEndAction=e=>{const t=this.velocityTracker.getYAcceleration();this.sheetHeight<=e?this.props.hideSheet():e>50&&t<=.08&&t>=-.02||t>.08?this.hide():0!==e&&this.show()},this.onSwipeAriaTouchEnd=()=>{const{deltaY:e}=this.state;this.onTouchEndAction(e),this.setState({startY:0,deltaY:0,swipeAreaTouched:!1})},this.onContentTouchEnd=()=>{const{deltaY:e,swipeAreaTouched:t}=this.state;this.props.allowHideOnContentScroll&&!t&&(this.onTouchEndAction(e),this.setState({startY:0,deltaY:0,contentTouched:!1}))},this.onVeilClick=()=>{this.setState({veilTouched:!0}),this.hide()},this.onVeilTransitionEnd=()=>{this.setState({isAnimating:!1}),"0"===this.veilOpacity&&this.props.hideSheet()},this.onContentTransitionEnd=e=>{"height"===e.propertyName&&this.sheetScrollContainerRef.current&&(this.sheetScrollContainerRef.current.style.transition="none")},this.onResizeWindow=()=>{this.state.isAnimating||(this.setState({inWindowResizeScope:!0}),this.resizeWindowTimer&&window.clearTimeout(this.resizeWindowTimer),this.resizeWindowTimer=window.setTimeout((()=>{this.onResize()}),50))},this.onResize=()=>{if(!this.sheetRef.current||!this.sheetScrollContainerRef.current)return;const e=this.sheetContentHeight;if(e===this.state.prevSheetHeight&&!this.state.inWindowResizeScope)return;const t=this.getAvailableContentHeight(e);this.sheetScrollContainerRef.current.style.transition=this.state.prevSheetHeight>e?"height 0s ease 0.3s":"none",this.sheetScrollContainerRef.current.style.height=`${t}px`,this.sheetRef.current.style.transform=`translate3d(0, -${t+this.sheetTopHeight}px, 0)`,this.setState({prevSheetHeight:e,inWindowResizeScope:!1})}}componentDidMount(){this.addListeners(),this.show();const e=this.getAvailableContentHeight(this.sheetContentHeight);this.setInitialStyles(e),this.setState({prevSheetHeight:e})}componentDidUpdate(e){const{visible:t,location:n}=this.props;!e.visible&&t&&this.show(),(e.visible&&!t||this.shouldClose(e))&&this.hide(),e.location.pathname!==n.pathname&&(h=[])}componentWillUnmount(){this.removeListeners()}render(){const{content:e,contentClassName:t,swipeAreaClassName:n,hideTopBar:i,title:s}=this.props,{deltaY:r,swipeAreaTouched:l,contentTouched:a,veilTouched:u,isAnimating:d}=this.state,h={"with-transition":!r||u},p={"with-transition":h["with-transition"]},v={"without-scroll":r>0&&a||l};return o.createElement(o.Fragment,null,o.createElement("div",{ref:this.veilRef,className:c("veil",h),onClick:d?void 0:this.onVeilClick,onTransitionEnd:this.onVeilTransitionEnd,role:"presentation"}),o.createElement("div",{ref:this.sheetRef,className:c("sheet",p),role:"dialog","aria-modal":"true","aria-label":s},!i&&o.createElement("div",{ref:this.sheetTopRef,className:c("sheet-top")},o.createElement("div",{className:c("sheet-top-resizer")})),o.createElement("div",{className:c("sheet-swipe-area",n),onTouchStart:this.onSwipeAreaTouchStart,onTouchMove:this.onSwipeAriaTouchMove,onTouchEnd:this.onSwipeAriaTouchEnd}),o.createElement("div",{ref:this.sheetScrollContainerRef,className:c("sheet-scroll-container",v),onTouchStart:this.onContentTouchStart,onTouchMove:this.onContentTouchMove,onTouchEnd:this.onContentTouchEnd,onTransitionEnd:this.onContentTransitionEnd},o.createElement("div",{ref:this.sheetContentBoxRef,className:c("sheet-content-box")},o.createElement("div",{className:c("sheet-content-box-border-compensation")},o.createElement("div",{className:c("sheet-content",t)},s&&o.createElement("div",{className:c("sheet-content-title")},s),o.createElement("div",null,e)))))))}get veilOpacity(){var e;return(null===(e=this.veilRef.current)||void 0===e?void 0:e.style.opacity)||0}get sheetTopHeight(){var e;return(null===(e=this.sheetTopRef.current)||void 0===e?void 0:e.getBoundingClientRect().height)||0}get sheetHeight(){var e;return(null===(e=this.sheetRef.current)||void 0===e?void 0:e.getBoundingClientRect().height)||0}get sheetScrollTop(){var e;return(null===(e=this.sheetScrollContainerRef.current)||void 0===e?void 0:e.scrollTop)||0}get sheetContentHeight(){var e;return(null===(e=this.sheetContentBoxRef.current)||void 0===e?void 0:e.getBoundingClientRect().height)||0}setInitialStyles(e){this.sheetScrollContainerRef.current&&this.sheetContentBoxRef.current&&(this.sheetScrollContainerRef.current.style.height=`${e}px`)}addListeners(){window.addEventListener("resize",this.onResizeWindow),this.sheetContentBoxRef.current&&(this.observer=new ResizeObserver((()=>{this.state.inWindowResizeScope||this.onResize()})),this.observer.observe(this.sheetContentBoxRef.current))}removeListeners(){window.removeEventListener("resize",this.onResizeWindow),this.observer&&this.observer.disconnect()}setHash(){const{id:e,platform:t,location:n,history:o}=this.props;if(t===l.O.BROWSER)return;const i=Object.assign(Object.assign({},n),{hash:e});switch(t){case l.O.IOS:n.hash&&h.push(n.hash),o.replace(i);break;case l.O.ANDROID:o.push(i)}}removeHash(){var e;const{id:t,platform:n,location:o,history:i}=this.props;if(n!==l.O.BROWSER&&o.hash===`#${t}`)switch(n){case l.O.IOS:i.replace(Object.assign(Object.assign({},o),{hash:null!==(e=h.pop())&&void 0!==e?e:""}));break;case l.O.ANDROID:i.goBack()}}shouldClose(e){const{id:t,platform:n,location:o,history:i}=this.props;return n!==l.O.BROWSER&&"POP"===i.action&&e.location.hash!==o.hash&&o.hash!==`#${t}`}}p.defaultProps={id:"sheet",allowHideOnContentScroll:!0};const v=function(e){var t;const n=(i=e).displayName||i.name||"Component";var i;return(t=class extends o.Component{render(){return o.createElement(e,Object.assign({},this.props,{mobile:this.context.mobile,platform:this.context.platform,useHistory:this.context.useHistory,useLocation:this.context.useLocation}))}}).displayName=`withMobile(${n})`,t.contextType=a.G,t}(function(e){const t=t=>{const{useHistory:n,useLocation:i}=t,s=(0,r.Tt)(t,["useHistory","useLocation"]);return o.createElement(e,Object.assign({},s,{history:n(),location:i()}))},n=e.displayName||e.name||"Component";return t.displayName=`withRouterWrapper(${n})`,t}(p)),m=({children:e,onClose:t,visible:n,id:r,title:l,className:a,contentClassName:u,swipeAreaClassName:d,allowHideOnContentScroll:h,hideTopBar:p,qa:m})=>{const[f,b]=o.useState(n),[g,C]=o.useState(n);(0,i.y)({enabled:f}),!g&&n&&b(!0),n!==g&&C(n);return f?o.createElement(s.Z,null,o.createElement("div",{"data-qa":m,className:c(null,a)},o.createElement(v,{id:r,content:e,contentClassName:u,swipeAreaClassName:d,title:l,visible:n,allowHideOnContentScroll:h,hideTopBar:p,hideSheet:()=>{t&&t(),b(!1)}}))):null}},51301:(e,t,n)=>{n.d(t,{R:()=>s});var o=n(59284);class i{constructor(e,t,n={}){var o,i;this.nativeEvent=t,this.target=null!==(o=n.target)&&void 0!==o?o:t.target,this.currentTarget=null!==(i=n.currentTarget)&&void 0!==i?i:t.currentTarget,this.relatedTarget=t.relatedTarget,this.bubbles=t.bubbles,this.cancelable=t.cancelable,this.defaultPrevented=t.defaultPrevented,this.eventPhase=t.eventPhase,this.isTrusted=t.isTrusted,this.timeStamp=t.timeStamp,this.type=e}isDefaultPrevented(){return this.nativeEvent.defaultPrevented}preventDefault(){this.defaultPrevented=!0,this.nativeEvent.preventDefault()}stopPropagation(){this.nativeEvent.stopPropagation(),this.isPropagationStopped=()=>!0}isPropagationStopped(){return!1}persist(){}}function s(e){const{onFocusWithin:t,onBlurWithin:n,onFocusWithinChange:s,isDisabled:r}=e,l=o.useRef(!1),a=o.useCallback((e=>{l.current||document.activeElement!==e.target||(l.current=!0,t&&t(e),s&&s(!0))}),[t,s]),c=o.useCallback((e=>{l.current&&(l.current=!1,n&&n(e),s&&s(!1))}),[n,s]),{onBlur:u,onFocus:d}=function({onFocus:e,onBlur:t,isDisabled:n}){const s=o.useRef(!1),r=o.useRef(null);o.useEffect((()=>{if(n)return;const e=function(){s.current=!1},o=function(e){if(!s.current&&r.current){const n=new FocusEvent("blur",Object.assign(Object.assign({},e),{relatedTarget:e.target,bubbles:!1,cancelable:!1}));t(new i("blur",n,{target:r.current,currentTarget:r.current})),r.current=null}};return window.addEventListener("focus",e,{capture:!0}),window.addEventListener("focusin",o),()=>{window.removeEventListener("focus",e,{capture:!0}),window.removeEventListener("focusin",o)}}),[n,t]);const l=o.useCallback((e=>{document.activeElement===e.target||null!==e.relatedTarget&&e.relatedTarget!==document.body&&e.relatedTarget!==document||(t(e),r.current=null)}),[t]),a=function(e){const t=o.useRef({isFocused:!1,observer:null});return o.useEffect((()=>{const e=t.current;return()=>{e.observer&&(e.observer.disconnect(),e.observer=null)}}),[]),o.useCallback((n=>{const o=n.target;if(o instanceof HTMLButtonElement||o instanceof HTMLInputElement||o instanceof HTMLTextAreaElement||o instanceof HTMLSelectElement){t.current.isFocused=!0;const n=n=>{t.current.isFocused=!1,o.disabled&&(null===e||void 0===e||e(new i("blur",n))),t.current.observer&&(t.current.observer.disconnect(),t.current.observer=null)};o.addEventListener("focusout",n,{once:!0});const s=new MutationObserver((()=>{if(t.current.isFocused&&o.disabled){s.disconnect(),t.current.observer=null;const e=o===document.activeElement?null:document.activeElement;o.dispatchEvent(new FocusEvent("blur",{relatedTarget:e})),o.dispatchEvent(new FocusEvent("focusout",{relatedTarget:e,bubbles:!0}))}}));s.observe(o,{attributes:!0,attributeFilter:["disabled"]}),t.current.observer=s}}),[e])}(t),c=o.useCallback((t=>{s.current=!0,r.current=t.target,a(t),e(t)}),[a,e]);return{onBlur:l,onFocus:c}}({onFocus:a,onBlur:c,isDisabled:r});return r?{focusWithinProps:{onFocus:void 0,onBlur:void 0}}:{focusWithinProps:{onFocus:d,onBlur:u}}}},92609:(e,t,n)=>{n.d(t,{F:()=>s});var o=n(59284),i=n(85736);const s=e=>{var t;const{onOpenChange:n,onClose:s}=e,r=o.useCallback((e=>{null===n||void 0===n||n(e),!1===e&&s&&s()}),[n,s]),[l,a]=(0,i.P)(e.open,null!==(t=e.defaultOpen)&&void 0!==t&&t,r),c=o.useCallback((e=>{a("boolean"===typeof e?e:!l)}),[l,a]);return{open:l,toggleOpen:c}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/39705.257f0583.chunk.js b/ydb/core/viewer/monitoring/static/js/39705.257f0583.chunk.js new file mode 100644 index 000000000000..398bf26ad99b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/39705.257f0583.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[39705],{39705:(e,a,r)=>{r.d(a,{default:()=>i});var t=r(79552);const i=r.n(t)()},79552:e=>{function a(e){e.languages.pascal={directive:{pattern:/\{\$[\s\S]*?\}/,greedy:!0,alias:["marco","property"]},comment:{pattern:/\(\*[\s\S]*?\*\)|\{[\s\S]*?\}|\/\/.*/,greedy:!0},string:{pattern:/(?:'(?:''|[^'\r\n])*'(?!')|#[&$%]?[a-f\d]+)+|\^[a-z]/i,greedy:!0},asm:{pattern:/(\basm\b)[\s\S]+?(?=\bend\s*[;[])/i,lookbehind:!0,greedy:!0,inside:null},keyword:[{pattern:/(^|[^&])\b(?:absolute|array|asm|begin|case|const|constructor|destructor|do|downto|else|end|file|for|function|goto|if|implementation|inherited|inline|interface|label|nil|object|of|operator|packed|procedure|program|record|reintroduce|repeat|self|set|string|then|to|type|unit|until|uses|var|while|with)\b/i,lookbehind:!0},{pattern:/(^|[^&])\b(?:dispose|exit|false|new|true)\b/i,lookbehind:!0},{pattern:/(^|[^&])\b(?:class|dispinterface|except|exports|finalization|finally|initialization|inline|library|on|out|packed|property|raise|resourcestring|threadvar|try)\b/i,lookbehind:!0},{pattern:/(^|[^&])\b(?:absolute|abstract|alias|assembler|bitpacked|break|cdecl|continue|cppdecl|cvar|default|deprecated|dynamic|enumerator|experimental|export|external|far|far16|forward|generic|helper|implements|index|interrupt|iochecks|local|message|name|near|nodefault|noreturn|nostackframe|oldfpccall|otherwise|overload|override|pascal|platform|private|protected|public|published|read|register|reintroduce|result|safecall|saveregisters|softfloat|specialize|static|stdcall|stored|strict|unaligned|unimplemented|varargs|virtual|write)\b/i,lookbehind:!0}],number:[/(?:[&%]\d+|\$[a-f\d]+)/i,/\b\d+(?:\.\d+)?(?:e[+-]?\d+)?/i],operator:[/\.\.|\*\*|:=|<[<=>]?|>[>=]?|[+\-*\/]=?|[@^=]/,{pattern:/(^|[^&])\b(?:and|as|div|exclude|in|include|is|mod|not|or|shl|shr|xor)\b/,lookbehind:!0}],punctuation:/\(\.|\.\)|[()\[\]:;,.]/},e.languages.pascal.asm.inside=e.languages.extend("pascal",{asm:void 0,keyword:void 0,operator:void 0}),e.languages.objectpascal=e.languages.pascal}e.exports=a,a.displayName="pascal",a.aliases=["objectpascal"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3977.4c33ec16.chunk.js b/ydb/core/viewer/monitoring/static/js/3977.4c33ec16.chunk.js deleted file mode 100644 index 660adc52b7d8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/3977.4c33ec16.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 3977.4c33ec16.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3977],{56358:(e,t,o)=>{o.r(t),o.d(t,{conf:()=>r,language:()=>n});var r={wordPattern:/(unary_[@~!#%^&*()\-=+\\|:<>\/?]+)|([a-zA-Z_$][\w$]*?_=)|(`[^`]+`)|([a-zA-Z_$][\w$]*)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*//\\s*(?:(?:#?region\\b)|(?:))")}}},n={tokenPostfix:".scala",keywords:["asInstanceOf","catch","class","classOf","def","do","else","extends","finally","for","foreach","forSome","if","import","isInstanceOf","macro","match","new","object","package","return","throw","trait","try","type","until","val","var","while","with","yield","given","enum","then"],softKeywords:["as","export","extension","end","derives","on"],constants:["true","false","null","this","super"],modifiers:["abstract","final","implicit","lazy","override","private","protected","sealed"],softModifiers:["inline","opaque","open","transparent","using"],name:/(?:[a-z_$][\w$]*|`[^`]+`)/,type:/(?:[A-Z][\w$]*)/,symbols:/[=>))/,["@brackets","white","variable"]],[/@name/,{cases:{"@keywords":"keyword","@softKeywords":"keyword","@modifiers":"keyword.modifier","@softModifiers":"keyword.modifier","@constants":{token:"constant",next:"@allowMethod"},"@default":{token:"identifier",next:"@allowMethod"}}}],[/@type/,"type","@allowMethod"],{include:"@whitespace"},[/@[a-zA-Z_$][\w$]*(?:\.[a-zA-Z_$][\w$]*)*/,"annotation"],[/[{(]/,"@brackets"],[/[})]/,"@brackets","@allowMethod"],[/\[/,"operator.square"],[/](?!\s*(?:va[rl]|def|type)\b)/,"operator.square","@allowMethod"],[/]/,"operator.square"],[/([=-]>|<-|>:|<:|:>|<%)(?=[\s\w()[\]{},\."'`])/,"keyword"],[/@symbols/,"operator"],[/[;,\.]/,"delimiter"],[/'[a-zA-Z$][\w$]*(?!')/,"attribute.name"],[/'[^\\']'/,"string","@allowMethod"],[/(')(@escapes)(')/,["string","string.escape",{token:"string",next:"@allowMethod"}]],[/'/,"string.invalid"]],import:[[/;/,"delimiter","@pop"],[/^|$/,"","@pop"],[/[ \t]+/,"white"],[/[\n\r]+/,"white","@pop"],[/\/\*/,"comment","@comment"],[/@name|@type/,"type"],[/[(){}]/,"@brackets"],[/[[\]]/,"operator.square"],[/[\.,]/,"delimiter"]],allowMethod:[[/^|$/,"","@pop"],[/[ \t]+/,"white"],[/[\n\r]+/,"white","@pop"],[/\/\*/,"comment","@comment"],[/(?==>[\s\w([{])/,"keyword","@pop"],[/(@name|@symbols)(?=[ \t]*[[({"'`]|[ \t]+(?:[+-]?\.?\d|\w))/,{cases:{"@keywords":{token:"keyword",next:"@pop"},"->|<-|>:|<:|<%":{token:"keyword",next:"@pop"},"@default":{token:"@rematch",next:"@pop"}}}],["","","@pop"]],comment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@push"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],case:[[/\b_\*/,"key"],[/\b(_|true|false|null|this|super)\b/,"keyword","@allowMethod"],[/\bif\b|=>/,"keyword","@pop"],[/`[^`]+`/,"identifier","@allowMethod"],[/@name/,"variable","@allowMethod"],[/:::?|\||@(?![a-z_$])/,"keyword"],{include:"@root"}],vardef:[[/\b_\*/,"key"],[/\b(_|true|false|null|this|super)\b/,"keyword"],[/@name/,"variable"],[/:::?|\||@(?![a-z_$])/,"keyword"],[/=|:(?!:)/,"operator","@pop"],[/$/,"white","@pop"],{include:"@root"}],string:[[/[^\\"\n\r]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}]],stringt:[[/[^\\"\n\r]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/"/,"string"]],fstring:[[/@escapes/,"string.escape"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/%%/,"string"],[/(%)([\-#+ 0,(])(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","keyword.modifier","number","metatag"]],[/(%)(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","number","metatag"]],[/(%)([\-#+ 0,(])(@fstring_conv)/,["metatag","keyword.modifier","metatag"]],[/(%)(@fstring_conv)/,["metatag","metatag"]],[/./,"string"]],fstringt:[[/@escapes/,"string.escape"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/%%/,"string"],[/(%)([\-#+ 0,(])(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","keyword.modifier","number","metatag"]],[/(%)(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","number","metatag"]],[/(%)([\-#+ 0,(])(@fstring_conv)/,["metatag","keyword.modifier","metatag"]],[/(%)(@fstring_conv)/,["metatag","metatag"]],[/./,"string"]],sstring:[[/@escapes/,"string.escape"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/./,"string"]],sstringt:[[/@escapes/,"string.escape"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/./,"string"]],interp:[[/{/,"operator","@push"],[/}/,"operator","@pop"],{include:"@root"}],rawstring:[[/[^"]/,"string"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}]],rawstringt:[[/[^"]/,"string"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/"/,"string"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3980.f3083535.chunk.js b/ydb/core/viewer/monitoring/static/js/3980.f3083535.chunk.js new file mode 100644 index 000000000000..d669723b627e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/3980.f3083535.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[3980],{3980:(n,t,E)=>{E.d(t,{default:()=>r});var e=E(90561);const r=E.n(e)()},90561:n=>{function t(n){!function(n){var t=/\b(?:ACT|ACTIFSUB|CARRAY|CASE|CLEARGIF|COA|COA_INT|CONSTANTS|CONTENT|CUR|EDITPANEL|EFFECT|EXT|FILE|FLUIDTEMPLATE|FORM|FRAME|FRAMESET|GIFBUILDER|GMENU|GMENU_FOLDOUT|GMENU_LAYERS|GP|HMENU|HRULER|HTML|IENV|IFSUB|IMAGE|IMGMENU|IMGMENUITEM|IMGTEXT|IMG_RESOURCE|INCLUDE_TYPOSCRIPT|JSMENU|JSMENUITEM|LLL|LOAD_REGISTER|NO|PAGE|RECORDS|RESTORE_REGISTER|TEMPLATE|TEXT|TMENU|TMENUITEM|TMENU_LAYERS|USER|USER_INT|_GIFBUILDER|global|globalString|globalVar)\b/;n.languages.typoscript={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?(?:\*\/|$)/,lookbehind:!0},{pattern:/(^|[^\\:= \t]|(?:^|[^= \t])[ \t]+)\/\/.*/,lookbehind:!0,greedy:!0},{pattern:/(^|[^"'])#.*/,lookbehind:!0,greedy:!0}],function:[{pattern://,inside:{string:{pattern:/"[^"\r\n]*"|'[^'\r\n]*'/,inside:{keyword:t}},keyword:{pattern:/INCLUDE_TYPOSCRIPT/}}},{pattern:/@import\s*(?:"[^"\r\n]*"|'[^'\r\n]*')/,inside:{string:/"[^"\r\n]*"|'[^'\r\n]*'/}}],string:{pattern:/^([^=]*=[< ]?)(?:(?!\]\n).)*/,lookbehind:!0,inside:{function:/\{\$.*\}/,keyword:t,number:/^\d+$/,punctuation:/[,|:]/}},keyword:t,number:{pattern:/\b\d+\s*[.{=]/,inside:{operator:/[.{=]/}},tag:{pattern:/\.?[-\w\\]+\.?/,inside:{punctuation:/\./}},punctuation:/[{}[\];(),.:|]/,operator:/[<>]=?|[!=]=?=?|--?|\+\+?|&&?|\|\|?|[?*/~^%]/},n.languages.tsconfig=n.languages.typoscript}(n)}n.exports=t,t.displayName="typoscript",t.aliases=["tsconfig"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40047.1e272b92.chunk.js b/ydb/core/viewer/monitoring/static/js/40047.1e272b92.chunk.js new file mode 100644 index 000000000000..1e00917e2e7d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40047.1e272b92.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40047],{40047:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"kk",weekdays:"\u0436\u0435\u043a\u0441\u0435\u043d\u0431\u0456_\u0434\u04af\u0439\u0441\u0435\u043d\u0431\u0456_\u0441\u0435\u0439\u0441\u0435\u043d\u0431\u0456_\u0441\u04d9\u0440\u0441\u0435\u043d\u0431\u0456_\u0431\u0435\u0439\u0441\u0435\u043d\u0431\u0456_\u0436\u04b1\u043c\u0430_\u0441\u0435\u043d\u0431\u0456".split("_"),weekdaysShort:"\u0436\u0435\u043a_\u0434\u04af\u0439_\u0441\u0435\u0439_\u0441\u04d9\u0440_\u0431\u0435\u0439_\u0436\u04b1\u043c_\u0441\u0435\u043d".split("_"),weekdaysMin:"\u0436\u043a_\u0434\u0439_\u0441\u0439_\u0441\u0440_\u0431\u0439_\u0436\u043c_\u0441\u043d".split("_"),months:"\u049b\u0430\u04a3\u0442\u0430\u0440_\u0430\u049b\u043f\u0430\u043d_\u043d\u0430\u0443\u0440\u044b\u0437_\u0441\u04d9\u0443\u0456\u0440_\u043c\u0430\u043c\u044b\u0440_\u043c\u0430\u0443\u0441\u044b\u043c_\u0448\u0456\u043b\u0434\u0435_\u0442\u0430\u043c\u044b\u0437_\u049b\u044b\u0440\u043a\u04af\u0439\u0435\u043a_\u049b\u0430\u0437\u0430\u043d_\u049b\u0430\u0440\u0430\u0448\u0430_\u0436\u0435\u043b\u0442\u043e\u049b\u0441\u0430\u043d".split("_"),monthsShort:"\u049b\u0430\u04a3_\u0430\u049b\u043f_\u043d\u0430\u0443_\u0441\u04d9\u0443_\u043c\u0430\u043c_\u043c\u0430\u0443_\u0448\u0456\u043b_\u0442\u0430\u043c_\u049b\u044b\u0440_\u049b\u0430\u0437_\u049b\u0430\u0440_\u0436\u0435\u043b".split("_"),weekStart:1,relativeTime:{future:"%s \u0456\u0448\u0456\u043d\u0434\u0435",past:"%s \u0431\u04b1\u0440\u044b\u043d",s:"\u0431\u0456\u0440\u043d\u0435\u0448\u0435 \u0441\u0435\u043a\u0443\u043d\u0434",m:"\u0431\u0456\u0440 \u043c\u0438\u043d\u0443\u0442",mm:"%d \u043c\u0438\u043d\u0443\u0442",h:"\u0431\u0456\u0440 \u0441\u0430\u0493\u0430\u0442",hh:"%d \u0441\u0430\u0493\u0430\u0442",d:"\u0431\u0456\u0440 \u043a\u04af\u043d",dd:"%d \u043a\u04af\u043d",M:"\u0431\u0456\u0440 \u0430\u0439",MM:"%d \u0430\u0439",y:"\u0431\u0456\u0440 \u0436\u044b\u043b",yy:"%d \u0436\u044b\u043b"},ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40060.5f9cbddd.chunk.js b/ydb/core/viewer/monitoring/static/js/40060.5f9cbddd.chunk.js new file mode 100644 index 000000000000..e85e6d5177ad --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40060.5f9cbddd.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40060],{40060:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"fa",weekdays:"\u06cc\u06a9\u200c\u0634\u0646\u0628\u0647_\u062f\u0648\u0634\u0646\u0628\u0647_\u0633\u0647\u200c\u0634\u0646\u0628\u0647_\u0686\u0647\u0627\u0631\u0634\u0646\u0628\u0647_\u067e\u0646\u062c\u200c\u0634\u0646\u0628\u0647_\u062c\u0645\u0639\u0647_\u0634\u0646\u0628\u0647".split("_"),weekdaysShort:"\u06cc\u06a9\u200c\u0634\u0646\u0628\u0647_\u062f\u0648\u0634\u0646\u0628\u0647_\u0633\u0647\u200c\u0634\u0646\u0628\u0647_\u0686\u0647\u0627\u0631\u0634\u0646\u0628\u0647_\u067e\u0646\u062c\u200c\u0634\u0646\u0628\u0647_\u062c\u0645\u0639\u0647_\u0634\u0646\u0628\u0647".split("_"),weekdaysMin:"\u06cc_\u062f_\u0633_\u0686_\u067e_\u062c_\u0634".split("_"),weekStart:6,months:"\u0698\u0627\u0646\u0648\u06cc\u0647_\u0641\u0648\u0631\u06cc\u0647_\u0645\u0627\u0631\u0633_\u0622\u0648\u0631\u06cc\u0644_\u0645\u0647_\u0698\u0648\u0626\u0646_\u0698\u0648\u0626\u06cc\u0647_\u0627\u0648\u062a_\u0633\u067e\u062a\u0627\u0645\u0628\u0631_\u0627\u06a9\u062a\u0628\u0631_\u0646\u0648\u0627\u0645\u0628\u0631_\u062f\u0633\u0627\u0645\u0628\u0631".split("_"),monthsShort:"\u0698\u0627\u0646\u0648\u06cc\u0647_\u0641\u0648\u0631\u06cc\u0647_\u0645\u0627\u0631\u0633_\u0622\u0648\u0631\u06cc\u0644_\u0645\u0647_\u0698\u0648\u0626\u0646_\u0698\u0648\u0626\u06cc\u0647_\u0627\u0648\u062a_\u0633\u067e\u062a\u0627\u0645\u0628\u0631_\u0627\u06a9\u062a\u0628\u0631_\u0646\u0648\u0627\u0645\u0628\u0631_\u062f\u0633\u0627\u0645\u0628\u0631".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"\u062f\u0631 %s",past:"%s \u067e\u06cc\u0634",s:"\u0686\u0646\u062f \u062b\u0627\u0646\u06cc\u0647",m:"\u06cc\u06a9 \u062f\u0642\u06cc\u0642\u0647",mm:"%d \u062f\u0642\u06cc\u0642\u0647",h:"\u06cc\u06a9 \u0633\u0627\u0639\u062a",hh:"%d \u0633\u0627\u0639\u062a",d:"\u06cc\u06a9 \u0631\u0648\u0632",dd:"%d \u0631\u0648\u0632",M:"\u06cc\u06a9 \u0645\u0627\u0647",MM:"%d \u0645\u0627\u0647",y:"\u06cc\u06a9 \u0633\u0627\u0644",yy:"%d \u0633\u0627\u0644"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40132.8f54cbd2.chunk.js b/ydb/core/viewer/monitoring/static/js/40132.8f54cbd2.chunk.js new file mode 100644 index 000000000000..f3c38b82c8d7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40132.8f54cbd2.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 40132.8f54cbd2.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40132],{40132:(e,t,o)=>{o.r(t),o.d(t,{conf:()=>r,language:()=>n});var r={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["{","}"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*\\{\\$REGION(\\s\\'.*\\')?\\}"),end:new RegExp("^\\s*\\{\\$ENDREGION\\}")}}},n={defaultToken:"",tokenPostfix:".pascal",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["absolute","abstract","all","and_then","array","as","asm","attribute","begin","bindable","case","class","const","contains","default","div","else","end","except","exports","external","far","file","finalization","finally","forward","generic","goto","if","implements","import","in","index","inherited","initialization","interrupt","is","label","library","mod","module","name","near","not","object","of","on","only","operator","or_else","otherwise","override","package","packed","pow","private","program","protected","public","published","interface","implementation","qualified","read","record","resident","requires","resourcestring","restricted","segment","set","shl","shr","specialize","stored","strict","then","threadvar","to","try","type","unit","uses","var","view","virtual","dynamic","overload","reintroduce","with","write","xor","true","false","procedure","function","constructor","destructor","property","break","continue","exit","abort","while","do","for","raise","repeat","until"],typeKeywords:["boolean","double","byte","integer","shortint","char","longint","float","string"],operators:["=",">","<","<=",">=","<>",":",":=","and","or","+","-","*","/","@","&","^","%"],symbols:/[=><:@\^&|+\-*\/\^%]+/,tokenizer:{root:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\$[0-9a-fA-F]{1,16}/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'/,"string","@string"],[/'[^\\']'/,"string"],[/'/,"string.invalid"],[/\#\d+/,"string"]],comment:[[/[^\*\}]+/,"comment"],[/\}/,"comment","@pop"],[/[\{]/,"comment"]],string:[[/[^\\']+/,"string"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"],[/\{/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/3977.4c33ec16.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/40132.8f54cbd2.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/3977.4c33ec16.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/40132.8f54cbd2.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/4018.f6c8e2ef.chunk.js b/ydb/core/viewer/monitoring/static/js/4018.f6c8e2ef.chunk.js new file mode 100644 index 000000000000..a2a56a919072 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/4018.f6c8e2ef.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4018],{4018:(e,t,s)=>{s.d(t,{default:()=>a});var r=s(63761);const a=s.n(r)()},63761:e=>{function t(e){e.languages.q={string:/"(?:\\.|[^"\\\r\n])*"/,comment:[{pattern:/([\t )\]}])\/.*/,lookbehind:!0,greedy:!0},{pattern:/(^|\r?\n|\r)\/[\t ]*(?:(?:\r?\n|\r)(?:.*(?:\r?\n|\r(?!\n)))*?(?:\\(?=[\t ]*(?:\r?\n|\r))|$)|\S.*)/,lookbehind:!0,greedy:!0},{pattern:/^\\[\t ]*(?:\r?\n|\r)[\s\S]+/m,greedy:!0},{pattern:/^#!.+/m,greedy:!0}],symbol:/`(?::\S+|[\w.]*)/,datetime:{pattern:/0N[mdzuvt]|0W[dtz]|\d{4}\.\d\d(?:m|\.\d\d(?:T(?:\d\d(?::\d\d(?::\d\d(?:[.:]\d\d\d)?)?)?)?)?[dz]?)|\d\d:\d\d(?::\d\d(?:[.:]\d\d\d)?)?[uvt]?/,alias:"number"},number:/\b(?![01]:)(?:0N[hje]?|0W[hj]?|0[wn]|0x[\da-fA-F]+|\d+(?:\.\d*)?(?:e[+-]?\d+)?[hjfeb]?)/,keyword:/\\\w+\b|\b(?:abs|acos|aj0?|all|and|any|asc|asin|asof|atan|attr|avgs?|binr?|by|ceiling|cols|cor|cos|count|cov|cross|csv|cut|delete|deltas|desc|dev|differ|distinct|div|do|dsave|ej|enlist|eval|except|exec|exit|exp|fby|fills|first|fkeys|flip|floor|from|get|getenv|group|gtime|hclose|hcount|hdel|hopen|hsym|iasc|identity|idesc|if|ij|in|insert|inter|inv|keys?|last|like|list|ljf?|load|log|lower|lsq|ltime|ltrim|mavg|maxs?|mcount|md5|mdev|med|meta|mins?|mmax|mmin|mmu|mod|msum|neg|next|not|null|or|over|parse|peach|pj|plist|prds?|prev|prior|rand|rank|ratios|raze|read0|read1|reciprocal|reval|reverse|rload|rotate|rsave|rtrim|save|scan|scov|sdev|select|set|setenv|show|signum|sin|sqrt|ssr?|string|sublist|sums?|sv|svar|system|tables|tan|til|trim|txf|type|uj|ungroup|union|update|upper|upsert|value|var|views?|vs|wavg|where|while|within|wj1?|wsum|ww|xasc|xbar|xcols?|xdesc|xexp|xgroup|xkey|xlog|xprev|xrank)\b/,adverb:{pattern:/['\/\\]:?|\beach\b/,alias:"function"},verb:{pattern:/(?:\B\.\B|\b[01]:|<[=>]?|>=?|[:+\-*%,!?~=|$&#@^]):?|\b_\b:?/,alias:"operator"},punctuation:/[(){}\[\];.]/}}e.exports=t,t.displayName="q",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4024.021c61dd.chunk.js b/ydb/core/viewer/monitoring/static/js/4024.021c61dd.chunk.js deleted file mode 100644 index b5a5a7f7b12b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4024.021c61dd.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4024],{94024:(e,t,n)=>{n.d(t,{registerYQLCompletionItemProvider:()=>B});var i=n(67913),s=n(23195),a=n(80781);const o=["Text","Bytes","String","Bool","Int32","Uint32","Int64","Uint64","Float","Double","Void","Yson","Utf8","Unit","Json","Date","Datetime","Timestamp","Interval","Date32","Datetime64","Timestamp64","Interval64","TzDate32","TzDatetime64","TzTimestamp64","Null","Int8","Uint8","Int16","Uint16","TzDate","TzDatetime","TzTimestamp","Uuid","EmptyList","EmptyDict","JsonDocument","DyNumber"],r=["CAST","COALESCE","LENGTH","LEN","SUBSTRING","FIND","RFIND","StartsWith","EndsWith","IF","NANVL","Random","RandomNumber","RandomUuid","CurrentUtcDate","CurrentUtcDatetime","CurrentUtcTimestamp","CurrentTzDate","CurrentTzDatetime","CurrentTzTimestamp","AddTimezone","RemoveTimezone","MAX_OF","MIN_OF","GREATEST","LEAST","AsTuple","AsStruct","AsList","AsDict","AsSet","AsListStrict","AsDictStrict","AsSetStrict","Variant","AsVariant","Enum","AsEnum","AsTagged","Untag","TableRow","JoinTableRow","Ensure","EnsureType","EnsureConvertibleTo","ToBytes","FromBytes","ByteAt","TestBit","ClearBit","SetBit","FlipBit","Abs","Just","Unwrap","Nothing","Callable","StaticMap","StaticZip","ListCreate","AsListStrict","ListLength","ListHasItems","ListCollect","ListSort","ListSortAsc","ListSortDesc","ListExtend","ListExtendStrict","ListUnionAll","ListZip","ListZipAll","ListEnumerate","ListReverse","ListSkip","ListTake","ListIndexOf","ListMap","ListFilter","ListFlatMap","ListNotNull","ListFlatten","ListUniq","ListAny","ListAll","ListHas","ListHead","ListLast","ListMin","ListMax","ListSum","ListAvg","ListFold","ListFold1","ListFoldMap","ListFold1Map","ListFromRange","ListReplicate","ListConcat","ListExtract","ListTakeWhile","ListSkipWhile","ListAggregate","ToDict","ToMultiDict","ToSet","DictCreate","SetCreate","DictLength","DictHasItems","DictItems","DictKeys","DictPayloads","DictLookup","DictContains","DictAggregate","SetIsDisjoint","SetIntersection","SetIncludes","SetUnion","SetDifference","SetSymmetricDifference","TryMember","ExpandStruct","AddMember","RemoveMember","ForceRemoveMember","ChooseMembers","RemoveMembers","ForceRemoveMembers","CombineMembers","FlattenMembers","StructMembers","RenameMembers","ForceRenameMembers","GatherMembers","SpreadMembers","ForceSpreadMembers","FormatType","ParseType","TypeOf","InstanceOf","DataType","OptionalType","ListType","StreamType","DictType","TupleType","StructType","VariantType","ResourceType","CallableType","GenericType","UnitType","VoidType","OptionalItemType","ListItemType","StreamItemType","DictKeyType","DictPayloadType","TupleElementType","StructMemberType","CallableResultType","CallableArgumentType","VariantUnderlyingType","JSON_EXISTS","JSON_VALUE","JSON_QUERY"],l=["COUNT","MIN","MAX","SUM","AVG","COUNT_IF","SUM_IF","AVG_IF","SOME","CountDistinctEstimate","HyperLogLog","AGGREGATE_LIST","AGGREGATE_LIST_DISTINCT","AGG_LIST","AGG_LIST_DISTINCT","MAX_BY","MIN_BY","AGGREGATE_BY","MULTI_AGGREGATE_BY","TOP","BOTTOM","TOP_BY","BOTTOM_BY","TOPFREQ","MODE","STDDEV","VARIANCE","CORRELATION","COVARIANCE","PERCENTILE","MEDIAN","HISTOGRAM","LogarithmicHistogram","LogHistogram","LinearHistogram","BOOL_AND","BOOL_OR","BOOL_XOR","BIT_AND","BIT_OR","BIT_XOR","SessionStart"],u=Object.entries({DateTime:["EndOfMonth","Format","FromMicroseconds","FromMilliseconds","FromSeconds","GetDayOfMonth","GetDayOfWeek","GetDayOfWeekName","GetDayOfYear","GetHour","GetMicrosecondOfSecond","GetMillisecondOfSecond","GetMinute","GetMonth","GetMonthName","GetSecond","GetTimezoneId","GetTimezoneName","GetWeekOfYear","GetWeekOfYearIso8601","GetYear","IntervalFromDays","IntervalFromHours","IntervalFromMicroseconds","IntervalFromMilliseconds","IntervalFromMinutes","IntervalFromSeconds","MakeDate","MakeDatetime","MakeTimestamp","MakeTzDate","MakeTzDatetime","MakeTzTimestamp","Parse","ParseHttp","ParseIso8601","ParseRfc822","ParseX509","ShiftMonths","ShiftQuarters","ShiftYears","Split","StartOf","StartOfDay","StartOfMonth","StartOfQuarter","StartOfWeek","StartOfYear","TimeOfDay","ToDays","ToHours","ToMicroseconds","ToMilliseconds","ToMinutes","ToSeconds","Update"],Dsv:["Parse","ReadRecord","Serialize"],String:["AsciiToLower","AsciiToTitle","AsciiToUpper","Base32Decode","Base32Encode","Base32StrictDecode","Base64Decode","Base64Encode","Base64EncodeUrl","Base64StrictDecode","Bin","BinText","CgiEscape","CgiUnescape","Collapse","CollapseText","Contains","DecodeHtml","EncodeHtml","EndsWith","EndsWithIgnoreCase","EscapeC","FromByteList","HasPrefix","HasPrefixIgnoreCase","HasSuffix","HasSuffixIgnoreCase","Hex","HexDecode","HexEncode","HexText","HumanReadableBytes","HumanReadableDuration","HumanReadableQuantity","IsAscii","IsAsciiAlnum","IsAsciiAlpha","IsAsciiDigit","IsAsciiHex","IsAsciiLower","IsAsciiSpace","IsAsciiUpper","JoinFromList","LeftPad","LevensteinDistance","Prec","RemoveAll","RemoveFirst","RemoveLast","ReplaceAll","ReplaceFirst","ReplaceLast","RightPad","SBin","SHex","SplitToList","StartsWith","StartsWithIgnoreCase","Strip","ToByteList","UnescapeC"],Unicode:["Find","Fold","FromCodePointList","GetLength","IsAlnum","IsAlpha","IsAscii","IsDigit","IsHex","IsLower","IsSpace","IsUnicodeSet","IsUpper","IsUtf","JoinFromList","LevensteinDistance","Normalize","NormalizeNFC","NormalizeNFD","NormalizeNFKC","NormalizeNFKD","RFind","RemoveAll","RemoveFirst","RemoveLast","ReplaceAll","ReplaceFirst","ReplaceLast","Reverse","SplitToList","Strip","Substring","ToCodePointList","ToLower","ToTitle","ToUint64","ToUpper","Translit","TryToUint64"],Url:["BuildQueryString","CanBePunycodeHostName","CutQueryStringAndFragment","CutScheme","CutWWW","CutWWW2","Decode","Encode","ForceHostNameToPunycode","ForcePunycodeToHostName","GetCGIParam","GetDomain","GetDomainLevel","GetFragment","GetHost","GetHostPort","GetOwner","GetPath","GetPort","GetScheme","GetSchemeHost","GetSchemeHostPort","GetSignificantDomain","GetTLD","GetTail","HostNameToPunycode","IsAllowedByRobotsTxt","IsKnownTLD","IsWellKnownTLD","Normalize","NormalizeWithDefaultHttpScheme","Parse","PunycodeToHostName","QueryStringToDict","QueryStringToList"],Yson:["Attributes","Contains","ConvertTo","ConvertToBool","ConvertToBoolDict","ConvertToBoolList","ConvertToDict","ConvertToDouble","ConvertToDoubleDict","ConvertToDoubleList","ConvertToInt64","ConvertToInt64Dict","ConvertToInt64List","ConvertToList","ConvertToString","ConvertToStringDict","ConvertToStringList","ConvertToUint64","ConvertToUint64Dict","ConvertToUint64List","Equals","From","GetHash","GetLength","IsBool","IsDict","IsDouble","IsEntity","IsInt64","IsList","IsString","IsUint64","Lookup","LookupBool","LookupDict","LookupDouble","LookupInt64","LookupList","LookupString","LookupUint64","Options","Parse","ParseJson","ParseJsonDecodeUtf8","Serialize","SerializeJson","SerializePretty","SerializeText","WithAttributes","YPath","YPathBool","YPathDict","YPathDouble","YPathInt64","YPathList","YPathString","YPathUint64"],HyperLogLog:["AddValue","Create","Deserialize","GetResult","Merge","Serialize"],Hyperscan:["BacktrackingGrep","BacktrackingMatch","Capture","Grep","Match","MultiGrep","MultiMatch","Replace"],Ip:["ConvertToIPv6","FromString","GetSubnet","GetSubnetByMask","IsEmbeddedIPv4","IsIPv4","IsIPv6","SubnetFromString","SubnetMatch","SubnetToString","ToFixedIPv6String","ToString"],Json:["BoolAsJsonNode","CompilePath","DoubleAsJsonNode","JsonAsJsonNode","JsonDocumentSqlExists","JsonDocumentSqlQuery","JsonDocumentSqlQueryConditionalWrap","JsonDocumentSqlQueryWrap","JsonDocumentSqlTryExists","JsonDocumentSqlValueBool","JsonDocumentSqlValueConvertToUtf8","JsonDocumentSqlValueInt64","JsonDocumentSqlValueNumber","JsonDocumentSqlValueUtf8","Parse","Serialize","SerializeToJsonDocument","SqlExists","SqlQuery","SqlQueryConditionalWrap","SqlQueryWrap","SqlTryExists","SqlValueBool","SqlValueConvertToUtf8","SqlValueInt64","SqlValueNumber","SqlValueUtf8","Utf8AsJsonNode"],Math:["Abs","Acos","Asin","Asinh","Atan","Atan2","Cbrt","Ceil","Cos","Cosh","E","Eps","Erf","ErfInv","ErfcInv","Exp","Exp2","Fabs","Floor","Fmod","FuzzyEquals","Hypot","IsFinite","IsInf","IsNaN","Ldexp","Lgamma","Log","Log10","Log2","Mod","NearbyInt","Pi","Pow","Rem","Remainder","Rint","Round","RoundDownward","RoundToNearest","RoundTowardZero","RoundUpward","Sigmoid","Sin","Sinh","Sqrt","Tan","Tanh","Tgamma","Trunc"],Pire:["Capture","Grep","Match","MultiGrep","MultiMatch","Replace"],Re2:["Capture","Count","Escape","FindAndConsume","Grep","Match","Options","PatternFromLike","Replace"],Re2posix:["Capture","Count","Escape","FindAndConsume","Grep","Match","Options","PatternFromLike","Replace"],Digest:["Argon2","Blake2B","CityHash","CityHash128","Crc32c","Crc64","FarmHashFingerprint","FarmHashFingerprint128","FarmHashFingerprint2","FarmHashFingerprint32","FarmHashFingerprint64","Fnv32","Fnv64","HighwayHash","IntHash64","Md5HalfMix","Md5Hex","Md5Raw","MurMurHash","MurMurHash2A","MurMurHash2A32","MurMurHash32","NumericHash","Sha1","Sha256","SipHash","SuperFastHash","XXH3","XXH3_128"],Histogram:["CalcLowerBound","CalcLowerBoundSafe","CalcUpperBound","CalcUpperBoundSafe","GetSumAboveBound","GetSumBelowBound","GetSumInRange","Normalize","Print","ToCumulativeDistributionFunction"]}).reduce(((e,[t,n])=>{const i=n.map((e=>`${t}::${e}`));return e.concat(i)}),[]),c=["ROW_NUMBER","LAG","LEAD","FIRST_VALUE","LAST_VALUE","RANK","DENSE_RANK","SessionState"],m=[],T=["TablePathPrefix","Warning"],d={table:["AUTO_PARTITIONING_BY_SIZE","AUTO_PARTITIONING_PARTITION_SIZE_MB","AUTO_PARTITIONING_BY_LOAD","AUTO_PARTITIONING_MIN_PARTITIONS_COUNT","AUTO_PARTITIONING_MAX_PARTITIONS_COUNT","UNIFORM_PARTITIONS","READ_REPLICAS_SETTINGS","TTL","KEY_BLOOM_FILTER","STORE"],view:["security_invoker"],topic:["min_active_partitions","partition_count_limit","retention_period","retention_storage_mb","partition_write_speed_bytes_per_second","partition_write_burst_bytes","metering_mode"],object:[],user:[],group:[],externalDataSource:[],externalTable:[],tableStore:[],replication:["ENDPOINT","DATABASE","USER","PASSWORD"],tableIndex:[],topicConsumer:["important","read_from"]},g={Method:0,Function:1,Constructor:2,Field:3,Variable:4,Class:5,Struct:6,Interface:7,Module:8,Property:9,Event:10,Operator:11,Unit:12,Value:13,Constant:14,Enum:15,EnumMember:16,Keyword:17,Text:18,Color:19,File:20,Reference:21,Customcolor:22,Folder:23,TypeParameter:24,User:25,Issue:26,Snippet:27},p=/[\s'"-/@]/,S={externalDataSource:["external_data_source"],externalTable:["external_table"],replication:["replication"],table:["table","column_table"],tableStore:["column_store"],topic:["pers_queue_group"],view:["view"],tableIndex:["table_index","index"]},I=["dir","unknown","ext_sub_domain"],L=["dir","ext_sub_domain"];function y(e){let t=e;return e.match(p)&&(t=`\`${e}\``),t}function b(e){let t=0,n=e.length;return e.startsWith("`")&&(t=1),e.endsWith("`")&&(n=-1),e.slice(t,n)}function A(e){return e.startsWith("$")}function C(e){return e.startsWith("/")?e.slice(1):e}function h(e="",t){const n=b(e);if(!n.startsWith("/"))return n;let i=C(n);const s=C(t);return i.startsWith(s)&&(i=i.slice(s.length)),C(i)}const D={suggestTemplates:0,suggestPragmas:1,suggestEntity:2,suggestAllColumns:3,suggestColumns:4,suggestColumnAliases:5,suggestVariables:6,suggestTableIndexes:7,suggestTableHints:8,suggestEntitySettings:9,suggestKeywords:10,suggestAggregateFunctions:11,suggestTableFunctions:12,suggestWindowFunctions:13,suggestFunctions:14,suggestSimpleTypes:15,suggestUdfs:16};function f(e){return D[e]}async function v(e,t,n,i){const s=h(i,n),o=await window.api.viewer.autocomplete({database:n,prefix:s,limit:1e3}),r=null===i||void 0===i?void 0:i.startsWith("`");if(o.Success){const n=function(e,t){const n=t.reduce(((e,t)=>{const n=S[t];return n&&n.forEach((t=>e.add(t))),e}),new Set(I));return null===e||void 0===e?void 0:e.filter((({Type:e})=>n.has(e)))}(o.Result.Entities,t);return n?n.reduce(((t,{Name:n,Type:i})=>{var s;const o=L.includes(i),l=o?`${n}/`:n;let u;o&&!r&&(u=`\`${l}$0\``);const c=t.length;return t.push({label:l,insertText:null!==(s=u)&&void 0!==s?s:l,kind:o?g.Folder:g.Text,insertTextRules:u?a.languages.CompletionItemInsertTextRule.InsertAsSnippet:a.languages.CompletionItemInsertTextRule.None,detail:i,range:e,command:l.endsWith("/")?{id:"editor.action.triggerSuggest",title:""}:void 0,sortText:G(f("suggestEntity"))+G(c)}),t}),[]):[]}return[]}async function F(e){return(await async function(){return r}()).map((t=>({label:t,insertText:t,kind:g.Function,detail:"Function",range:e,sortText:G(f("suggestFunctions"))})))}async function E(e){return(await async function(){return o}()).map((t=>({label:t,insertText:t,kind:g.TypeParameter,detail:"Type",range:e,sortText:G(f("suggestSimpleTypes"))})))}async function M(e){return(await async function(){return u}()).map((t=>({label:t,insertText:t,kind:g.Function,detail:"UDF",range:e,sortText:G(f("suggestUdfs"))})))}async function N(e){return(await async function(){return c}()).map((t=>({label:t,insertText:t,kind:g.Function,detail:"Window function",range:e,sortText:G(f("suggestWindowFunctions"))})))}async function R(e){return(await async function(){return m}()).map((t=>({label:t,insertText:t,kind:g.Function,detail:"Table function",range:e,sortText:G(f("suggestTableFunctions"))})))}async function _(e){return(await async function(){return l}()).map((t=>({label:t,insertText:t,kind:g.Function,detail:"Aggregate function",range:e,sortText:G(f("suggestAggregateFunctions"))})))}async function P(e){return(await async function(){return T}()).map((t=>({label:t,insertText:t,kind:g.Module,detail:"Pragma",range:e,sortText:G(f("suggestPragmas"))})))}async function x(e,t){const n=await async function(e){return d[e]}(t);return n.map((t=>({label:t,insertText:t,kind:g.Property,detail:"Setting",range:e,sortText:G(f("suggestEntitySettings"))})))}const O="abcdefghijklmnopqrstuvwxyz";function G(e){const t=O[e];if(t)return t;const n=Math.floor(e/O.length),i=e%O.length;return O.slice(-1).repeat(n)+O[i]}function U(e){return async(t,i,s,a)=>{const o=function(e,t){const{startColumn:n,endColumn:i}=e.getWordUntilPosition(t),s="$"===e.getLineContent(t.lineNumber)[n-2]?1:0;return{startColumn:n-s,startLineNumber:t.lineNumber,endColumn:i,endLineNumber:t.lineNumber}}(t,i),r=await async function(e,t,i,s){const{parseYqlQuery:a}=await Promise.resolve().then(n.bind(n,41614)),o={line:t.lineNumber,column:t.column},r=a(e.getValue(),o);let l=[],u=[],c=[],m=[],T=[],d=[],p=[],S=[],I=[],L=[];if(r.suggestEntity){const n=function(e,t){var n,i,s,a;const o=e.findPreviousMatch("\\s(`?[^\\s]*)",t,!0,!1,null,!0),r=e.findNextMatch("([^\\s]*)`?",t,!0,!1,null,!0);return`${null!==(n=null===o||void 0===o||null===(i=o.matches)||void 0===i?void 0:i[1])&&void 0!==n?n:""}${null!==(s=null===r||void 0===r||null===(a=r.matches)||void 0===a?void 0:a[1])&&void 0!==s?s:""}`}(e,t);l=await v(i,r.suggestEntity,s,n)}r.suggestFunctions&&(u=await F(i));r.suggestAggregateFunctions&&(c=await _(i));r.suggestWindowFunctions&&(m=await N(i));r.suggestTableFunctions&&(T=await R(i));r.suggestSimpleTypes&&(p=await E(i));r.suggestVariables&&(L=function(e,t){return t?t.map((({name:t})=>{const n="$"+t;return{label:n,insertText:n,kind:g.Variable,detail:"Variable",range:e,sortText:G(f("suggestVariables"))}})):[]}(i,r.suggestVariables));r.suggestUdfs&&(d=await M(i));r.suggestPragmas&&(S=await P(i));r.suggestEntitySettings&&(I=await x(i,r.suggestEntitySettings));const C=await function(e,t){return t?null===t||void 0===t?void 0:t.map((t=>({label:t.name,insertText:t.name,kind:g.Variable,detail:"Column alias",range:e,sortText:G(f("suggestColumnAliases"))}))):[]}(i,r.suggestColumnAliases),D=await async function(e,t,n,i){var s,a,o;if(null===t||void 0===t||!t.tables)return[];const r=[],l=t.all?[]:void 0,u=t.tables.length>1,c=null!==(s=null===(a=t.tables)||void 0===a?void 0:a.map((e=>{let t=b(e.name);return t.endsWith("/")||A(t)||(t=`${t}/`),{...e,name:h(t,i)}})))&&void 0!==s?s:[],m=c.map((e=>e.name)),T=Array.from(new Set(m)),d=T.filter((e=>!A(e)));let p=[];if(d.length){const e=await window.api.viewer.autocomplete({database:i,table:d,limit:1e3});var S;e.Success&&(p=null!==(S=e.Result.Entities)&&void 0!==S?S:[])}const I=T.filter(A),L=[];I.length&&I.forEach((e=>{var t,i,s,a;const o=null!==(t=null===n||void 0===n||null===(i=n.find((t=>e.slice(1)===t.name)))||void 0===i||null===(s=i.value)||void 0===s||null===(a=s.columns)||void 0===a?void 0:a.map((t=>({Name:t,Type:"column",Parent:e}))))&&void 0!==t?t:[];L.push(...o)}));const C=c.reduce(((e,t)=>{const n=t.columns;return n&&e.push(...n.map((e=>({Name:e,Type:"column",Parent:t.name})))),e}),[]),D=null===(o=t.tables)||void 0===o?void 0:o.reduce(((e,t)=>{var n;const s=h(b(t.name),i),a=null!==(n=e[s])&&void 0!==n?n:[];return t.alias&&a.push(t.alias),e[s]=a,e}),{});if([...p,...L,...C].forEach((t=>{if("column"!==t.Type)return;const n=function(e){const{PKIndex:t,NotNull:n,Default:i}=e,s=[];return void 0!==t&&s.push(`PK${t}`),n&&s.push("NN"),i&&s.push("Default"),s.length?s.join(", "):""}(t),s=y(t.Name),a=h(t.Parent,i),o=D[a],c=r.length;if(null!==o&&void 0!==o&&o.length)o.forEach((t=>{const i=`${t}.${s}`;r.push({label:{label:i,description:n},insertText:i,kind:g.Variable,detail:"Column",range:e,sortText:G(f("suggestColumns"))+G(c)}),null===l||void 0===l||l.push(i)}));else{let t=s;u&&(t=`${y(a)}.${s}`),r.push({label:{label:t,description:n},insertText:t,kind:g.Variable,detail:"Column",range:e,sortText:G(f("suggestColumns"))+G(c)}),null===l||void 0===l||l.push(t)}})),l&&l.length>1){const t=l.join(", ");r.push({label:t,insertText:t,kind:g.Variable,range:e,sortText:G(f("suggestAllColumns"))})}return r}(i,r.suggestColumns,r.suggestVariables,s),O=function(e,t){return t?t.map((t=>({label:t.value,insertText:t.value,kind:g.Keyword,detail:"Keyword",range:e,sortText:G(f("suggestKeywords"))}))):[]}(i,r.suggestKeywords),U=[...l,...u,...m,...T,...d,...p,...S,...C,...D,...O,...c,...I,...L];return U}(t,i,o,e);return{suggestions:r}}}let w;function B(e){w&&w.dispose(),w=i.eo.registerCompletionItemProvider(s.l,{triggerCharacters:[" ",".","`","(","/"],provideCompletionItems:U(e)})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40388.be25f07a.chunk.js b/ydb/core/viewer/monitoring/static/js/40388.be25f07a.chunk.js new file mode 100644 index 000000000000..56667eb41b97 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40388.be25f07a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40388],{33299:e=>{function u(e){e.languages.bsl={comment:/\/\/.*/,string:[{pattern:/"(?:[^"]|"")*"(?!")/,greedy:!0},{pattern:/'(?:[^'\r\n\\]|\\.)*'/}],keyword:[{pattern:/(^|[^\w\u0400-\u0484\u0487-\u052f\u1d2b\u1d78\u2de0-\u2dff\ua640-\ua69f\ufe2e\ufe2f])(?:\u043f\u043e\u043a\u0430|\u0434\u043b\u044f|\u043d\u043e\u0432\u044b\u0439|\u043f\u0440\u0435\u0440\u0432\u0430\u0442\u044c|\u043f\u043e\u043f\u044b\u0442\u043a\u0430|\u0438\u0441\u043a\u043b\u044e\u0447\u0435\u043d\u0438\u0435|\u0432\u044b\u0437\u0432\u0430\u0442\u044c\u0438\u0441\u043a\u043b\u044e\u0447\u0435\u043d\u0438\u0435|\u0438\u043d\u0430\u0447\u0435|\u043a\u043e\u043d\u0435\u0446\u043f\u043e\u043f\u044b\u0442\u043a\u0438|\u043d\u0435\u043e\u043f\u0440\u0435\u0434\u0435\u043b\u0435\u043d\u043e|\u0444\u0443\u043d\u043a\u0446\u0438\u044f|\u043f\u0435\u0440\u0435\u043c|\u0432\u043e\u0437\u0432\u0440\u0430\u0442|\u043a\u043e\u043d\u0435\u0446\u0444\u0443\u043d\u043a\u0446\u0438\u0438|\u0435\u0441\u043b\u0438|\u0438\u043d\u0430\u0447\u0435\u0435\u0441\u043b\u0438|\u043f\u0440\u043e\u0446\u0435\u0434\u0443\u0440\u0430|\u043a\u043e\u043d\u0435\u0446\u043f\u0440\u043e\u0446\u0435\u0434\u0443\u0440\u044b|\u0442\u043e\u0433\u0434\u0430|\u0437\u043d\u0430\u0447|\u044d\u043a\u0441\u043f\u043e\u0440\u0442|\u043a\u043e\u043d\u0435\u0446\u0435\u0441\u043b\u0438|\u0438\u0437|\u043a\u0430\u0436\u0434\u043e\u0433\u043e|\u0438\u0441\u0442\u0438\u043d\u0430|\u043b\u043e\u0436\u044c|\u043f\u043e|\u0446\u0438\u043a\u043b|\u043a\u043e\u043d\u0435\u0446\u0446\u0438\u043a\u043b\u0430|\u0432\u044b\u043f\u043e\u043b\u043d\u0438\u0442\u044c)(?![\w\u0400-\u0484\u0487-\u052f\u1d2b\u1d78\u2de0-\u2dff\ua640-\ua69f\ufe2e\ufe2f])/i,lookbehind:!0},{pattern:/\b(?:break|do|each|else|elseif|enddo|endfunction|endif|endprocedure|endtry|except|execute|export|false|for|function|if|in|new|null|procedure|raise|return|then|to|true|try|undefined|val|var|while)\b/i}],number:{pattern:/(^(?=\d)|[^\w\u0400-\u0484\u0487-\u052f\u1d2b\u1d78\u2de0-\u2dff\ua640-\ua69f\ufe2e\ufe2f])(?:\d+(?:\.\d*)?|\.\d+)(?:E[+-]?\d+)?/i,lookbehind:!0},operator:[/[<>+\-*/]=?|[%=]/,{pattern:/(^|[^\w\u0400-\u0484\u0487-\u052f\u1d2b\u1d78\u2de0-\u2dff\ua640-\ua69f\ufe2e\ufe2f])(?:\u0438|\u0438\u043b\u0438|\u043d\u0435)(?![\w\u0400-\u0484\u0487-\u052f\u1d2b\u1d78\u2de0-\u2dff\ua640-\ua69f\ufe2e\ufe2f])/i,lookbehind:!0},{pattern:/\b(?:and|not|or)\b/i}],punctuation:/\(\.|\.\)|[()\[\]:;,.]/,directive:[{pattern:/^([ \t]*)&.*/m,lookbehind:!0,greedy:!0,alias:"important"},{pattern:/^([ \t]*)#.*/gm,lookbehind:!0,greedy:!0,alias:"important"}]},e.languages.oscript=e.languages.bsl}e.exports=u,u.displayName="bsl",u.aliases=[]},40388:(e,u,d)=>{d.d(u,{default:()=>n});var a=d(33299);const n=d.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40507.07624918.chunk.js b/ydb/core/viewer/monitoring/static/js/40507.07624918.chunk.js new file mode 100644 index 000000000000..e1011b1182a4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40507.07624918.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40507],{62888:(e,n,t)=>{t.d(n,{default:()=>a});var i=t(81857);const a=t.n(i)()},81857:e=>{function n(e){!function(e){var n=/\\\((?:[^()]|\([^()]*\))*\)/.source,t=RegExp(/(^|[^\\])"(?:[^"\r\n\\]|\\[^\r\n(]|__)*"/.source.replace(/__/g,(function(){return n}))),i={interpolation:{pattern:RegExp(/((?:^|[^\\])(?:\\{2})*)/.source+n),lookbehind:!0,inside:{content:{pattern:/^(\\\()[\s\S]+(?=\)$)/,lookbehind:!0,inside:null},punctuation:/^\\\(|\)$/}}},a=e.languages.jq={comment:/#.*/,property:{pattern:RegExp(t.source+/(?=\s*:(?!:))/.source),lookbehind:!0,greedy:!0,inside:i},string:{pattern:t,lookbehind:!0,greedy:!0,inside:i},function:{pattern:/(\bdef\s+)[a-z_]\w+/i,lookbehind:!0},variable:/\B\$\w+/,"property-literal":{pattern:/\b[a-z_]\w*(?=\s*:(?!:))/i,alias:"property"},keyword:/\b(?:as|break|catch|def|elif|else|end|foreach|if|import|include|label|module|modulemeta|null|reduce|then|try|while)\b/,boolean:/\b(?:false|true)\b/,number:/(?:\b\d+\.|\B\.)?\b\d+(?:[eE][+-]?\d+)?\b/,operator:[{pattern:/\|=?/,alias:"pipe"},/\.\.|[!=<>]?=|\?\/\/|\/\/=?|[-+*/%]=?|[<>?]|\b(?:and|not|or)\b/],"c-style-function":{pattern:/\b[a-z_]\w*(?=\s*\()/i,alias:"function"},punctuation:/::|[()\[\]{},:;]|\.(?=\s*[\[\w$])/,dot:{pattern:/\./,alias:"important"}};i.interpolation.inside.content.inside=a}(e)}e.exports=n,n.displayName="jq",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40710.a00731c6.chunk.js b/ydb/core/viewer/monitoring/static/js/40710.a00731c6.chunk.js new file mode 100644 index 000000000000..d478491cd97e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40710.a00731c6.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40710],{40710:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"uz",weekdays:"\u042f\u043a\u0448\u0430\u043d\u0431\u0430_\u0414\u0443\u0448\u0430\u043d\u0431\u0430_\u0421\u0435\u0448\u0430\u043d\u0431\u0430_\u0427\u043e\u0440\u0448\u0430\u043d\u0431\u0430_\u041f\u0430\u0439\u0448\u0430\u043d\u0431\u0430_\u0416\u0443\u043c\u0430_\u0428\u0430\u043d\u0431\u0430".split("_"),months:"\u044f\u043d\u0432\u0430\u0440_\u0444\u0435\u0432\u0440\u0430\u043b_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0435\u043b_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043d\u0442\u044f\u0431\u0440_\u043e\u043a\u0442\u044f\u0431\u0440_\u043d\u043e\u044f\u0431\u0440_\u0434\u0435\u043a\u0430\u0431\u0440".split("_"),weekStart:1,weekdaysShort:"\u042f\u043a\u0448_\u0414\u0443\u0448_\u0421\u0435\u0448_\u0427\u043e\u0440_\u041f\u0430\u0439_\u0416\u0443\u043c_\u0428\u0430\u043d".split("_"),monthsShort:"\u044f\u043d\u0432_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433_\u0441\u0435\u043d_\u043e\u043a\u0442_\u043d\u043e\u044f_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u042f\u043a_\u0414\u0443_\u0421\u0435_\u0427\u043e_\u041f\u0430_\u0416\u0443_\u0428\u0430".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"D MMMM YYYY, dddd HH:mm"},relativeTime:{future:"\u042f\u043a\u0438\u043d %s \u0438\u0447\u0438\u0434\u0430",past:"%s \u043e\u043b\u0434\u0438\u043d",s:"\u0444\u0443\u0440\u0441\u0430\u0442",m:"\u0431\u0438\u0440 \u0434\u0430\u043a\u0438\u043a\u0430",mm:"%d \u0434\u0430\u043a\u0438\u043a\u0430",h:"\u0431\u0438\u0440 \u0441\u043e\u0430\u0442",hh:"%d \u0441\u043e\u0430\u0442",d:"\u0431\u0438\u0440 \u043a\u0443\u043d",dd:"%d \u043a\u0443\u043d",M:"\u0431\u0438\u0440 \u043e\u0439",MM:"%d \u043e\u0439",y:"\u0431\u0438\u0440 \u0439\u0438\u043b",yy:"%d \u0439\u0438\u043b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/40730.5e1bc3d1.chunk.js b/ydb/core/viewer/monitoring/static/js/40730.5e1bc3d1.chunk.js new file mode 100644 index 000000000000..18fdb0eb7428 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/40730.5e1bc3d1.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[40730],{40730:function(e){e.exports=function(){"use strict";return{name:"en",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),ordinal:function(e){var _=["th","st","nd","rd"],a=e%100;return"["+e+(_[(a-20)%10]||_[a]||_[0])+"]"}}}()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4096.33f702a0.chunk.js b/ydb/core/viewer/monitoring/static/js/4096.33f702a0.chunk.js deleted file mode 100644 index 2e52252aef4c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4096.33f702a0.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4096],{44096:function(t,_,e){t.exports=function(t){"use strict";function _(t){return t&&"object"==typeof t&&"default"in t?t:{default:t}}var e=_(t),a={name:"mt",weekdays:"Il-\u0126add_It-Tnejn_It-Tlieta_L-Erbg\u0127a_Il-\u0126amis_Il-\u0120img\u0127a_Is-Sibt".split("_"),months:"Jannar_Frar_Marzu_April_Mejju_\u0120unju_Lulju_Awwissu_Settembru_Ottubru_Novembru_Di\u010bembru".split("_"),weekStart:1,weekdaysShort:"\u0126ad_Tne_Tli_Erb_\u0126am_\u0120im_Sib".split("_"),monthsShort:"Jan_Fra_Mar_Apr_Mej_\u0120un_Lul_Aww_Set_Ott_Nov_Di\u010b".split("_"),weekdaysMin:"\u0126a_Tn_Tl_Er_\u0126a_\u0120i_Si".split("_"),ordinal:function(t){return t},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"f\u2019 %s",past:"%s ilu",s:"ftit sekondi",m:"minuta",mm:"%d minuti",h:"sieg\u0127a",hh:"%d sieg\u0127at",d:"\u0121urnata",dd:"%d \u0121ranet",M:"xahar",MM:"%d xhur",y:"sena",yy:"%d sni"}};return e.default.locale(a,null,!0),a}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4130.e9433987.chunk.js b/ydb/core/viewer/monitoring/static/js/4130.e9433987.chunk.js deleted file mode 100644 index dc20441bbe95..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4130.e9433987.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4130],{69775:(e,t,n)=>{"use strict";n.d(t,{O:()=>Ce});var i=n(59284),s=n(27738),a=n(84476),d=n(99991),l=n(66821);const r=e=>i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),i.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M10.5 6V5a2.5 2.5 0 0 0-5 0v1zM4 5v1a3 3 0 0 0-3 3v3a3 3 0 0 0 3 3h8a3 3 0 0 0 3-3V9a3 3 0 0 0-3-3V5a4 4 0 0 0-8 0m6.5 2.5H12A1.5 1.5 0 0 1 13.5 9v3a1.5 1.5 0 0 1-1.5 1.5H4A1.5 1.5 0 0 1 2.5 12V9A1.5 1.5 0 0 1 4 7.5zm-1.75 2a.75.75 0 0 0-1.5 0v2a.75.75 0 0 0 1.5 0z",clipRule:"evenodd"}));var o=n(53202),c=n(90826),u=n(46734),m=n(98089),p=n(32084),I=n(51301),v=n(92609),b=n(19884),g=n(93628),f=n(27145),y=n(87184),h=n(69220);const x=(0,h.om)("list-container-view"),S=i.forwardRef((function({as:e="div",role:t="listbox",children:n,id:s,className:a,fixedHeight:d,extraProps:l,qa:r,style:o},c){return i.createElement(y.s,Object.assign({qa:r,as:e,direction:"column",ref:c,grow:!0,tabIndex:-1,id:s,role:t,style:o,className:x({"fixed-height":d},a)},l),n)})),B=e=>null!==e&&"object"===typeof e&&"data"in e,E=(0,h.om)("list-recursive-renderer");function C(e){var t,{id:n,itemSchema:s,list:a}=e,d=(0,f.Tt)(e,["id","itemSchema","list"]);const l=d.children(n,a.structure.idToFlattenIndex[n]);if(B(s)&&s.children){const e=!a.state.expandedById||!(n in a.state.expandedById)||a.state.expandedById[n];return i.createElement("ul",{style:d.style,className:E(null,d.className),role:"group"},l,e&&Boolean(null===(t=a.structure.groupsState[n])||void 0===t?void 0:t.childrenIds)&&s.children.map(((e,t)=>i.createElement(C,Object.assign({list:a,id:a.structure.groupsState[n].childrenIds[t],itemSchema:e,key:t},d)))))}return l}function O(e){var{containerRef:t,renderItem:n,list:s}=e,a=(0,f.Tt)(e,["containerRef","renderItem","list"]);return i.createElement(S,Object.assign({ref:t},a),s.structure.items.map(((e,t)=>i.createElement(C,{key:t,itemSchema:e,id:s.structure.rootIds[t],list:s},n))))}const w=({list:e,multiple:t})=>({id:n})=>{e.state.disabledById[n]||(e.state.setActiveItemId(n),e.state.expandedById&&n in e.state.expandedById&&e.state.setExpanded?e.state.setExpanded((e=>Object.assign(Object.assign({},e),{[n]:!e[n]}))):e.state.setSelected((e=>Object.assign(Object.assign({},t?e:{}),{[n]:!t||!e[n]}))))};var j=n(359);const k="data-list-item",N={s:[22,44],m:[26,44],l:[34,52],xl:[44,62]},R=({containerRef:e,onItemClick:t,enabled:n,list:s})=>{const a=i.useCallback(((t,n=!0)=>{var i,a;"number"===typeof t&&s.structure.visibleFlattenIds[t]&&(n&&((e,t)=>{var n;if(document){const i=(t||document).querySelector(`[${k}="${e}"]`);i&&(null===(n=i.scrollIntoView)||void 0===n||n.call(i,{block:"nearest"}))}})(s.structure.visibleFlattenIds[t],null===e||void 0===e?void 0:e.current),null===(a=(i=s.state).setActiveItemId)||void 0===a||a.call(i,s.structure.visibleFlattenIds[t]))}),[s.structure.visibleFlattenIds,s.state,e]),d=i.useCallback(((e,t,n=0)=>{e.preventDefault();const i="string"===typeof s.state.activeItemId?s.structure.visibleFlattenIds.findIndex((e=>e===s.state.activeItemId)):-1,d=(({list:e,index:t,step:n,disabledItemsById:i={}})=>{const s=e.length;let a=(t+s)%s;for(let d=0;d-1?i:n)+t,step:Math.sign(t),disabledItemsById:s.state.disabledById});a(d)}),[a,s.state.activeItemId,s.state.disabledById,s.structure.visibleFlattenIds]);i.useLayoutEffect((()=>{const i=null===e||void 0===e?void 0:e.current;if(n||!i)return;const a=e=>{switch(e.key){case j.D.ARROW_DOWN:d(e,1,-1);break;case j.D.ARROW_UP:d(e,-1);break;case j.D.SPACEBAR:case j.D.ENTER:s.state.activeItemId&&!s.state.disabledById[s.state.activeItemId]&&(e.preventDefault(),null===t||void 0===t||t({id:s.state.activeItemId}))}};return i.addEventListener("keydown",a),()=>{i.removeEventListener("keydown",a)}}),[e,n,d,s.state.activeItemId,s.state.disabledById,t])};var D=n(46423),F=n(25569),P=n(63365),T=n(33705);const $=(0,h.om)("list-item-expand-icon"),A=({expanded:e,behavior:t="action",disabled:n})=>i.createElement(T.I,{direction:z({behavior:t,expanded:e}),className:$(null,(0,P.$)({color:n?"hint":void 0})),size:16});function z({behavior:e,expanded:t}){return t&&"action"===e?"top":t&&"state"===e||t&&"state-inverse"===e||"action"===e?"bottom":"state"===e?"right":"state-inverse"===e?"left":"bottom"}const M=(0,h.om)("list-item-view"),L=e=>"object"===typeof e&&null!==e&&"title"in e,q=e=>{var{children:t,indentation:n=1,className:s}=e,a=(0,f.Tt)(e,["children","indentation","className"]);return i.createElement(y.s,Object.assign({width:16*n,className:M("slot",s)},a),t)},_=({startSlot:e,subtitle:t,endSlot:n,disabled:s,hasSelectionIcon:a,isGroup:l,indentation:r,expanded:o,selected:c,title:u,expandIconPlacement:p="start",renderExpandIcon:I=A})=>{const v=l?i.createElement(I,{behavior:"start"===p?"state":"action",expanded:o,disabled:s}):null;return i.createElement(y.s,{alignItems:"center",justifyContent:"space-between",gap:"4",className:M("content")},i.createElement(y.s,{gap:"2",alignItems:"center",grow:!0},a&&i.createElement(q,null,c?i.createElement(d.I,{data:F.A,size:16,className:(0,P.$)({color:"info"})}):null),(e=>e&&e>=1?i.createElement(q,{indentation:Math.floor(e)}):null)(r),"start"===p&&v,e,i.createElement("div",{className:M("main-content")},"string"===typeof u?i.createElement(m.E,{ellipsis:!0,color:s?"hint":void 0,variant:l?"subheader-1":void 0},u):u,"string"===typeof t?i.createElement(m.E,{ellipsis:!0,color:s?"hint":"secondary"},t):t)),i.createElement(y.s,{gap:"2"},"end"===p&&v,n))},V=i.forwardRef((function(e,t){var{id:n,as:s,size:a="m",active:d,selected:l,disabled:r,selectionViewType:o="multiple",activeOnHover:c,className:u,height:m,dragging:p,style:I,content:v,role:b="option",onClick:g}=e,y=(0,f.Tt)(e,["id","as","size","active","selected","disabled","selectionViewType","activeOnHover","className","height","dragging","style","content","role","onClick"]);const h=s||"li",x=r?void 0:g,S="boolean"===typeof c?c:Boolean(x),B=Object.assign({minHeight:`var(--g-list-item-height, ${null!==m&&void 0!==m?m:N[a][Number(Boolean(!!L(v)&&(null===v||void 0===v?void 0:v.subtitle)))]}px)`},I);return i.createElement(h,Object.assign({[k]:n,role:b,"aria-selected":l,onClick:x,className:M({active:p||d,selected:l&&"single"===o,activeOnHover:S,radius:a,size:a,dragging:p,clickable:Boolean(x)},(0,D.Y)({px:2},u)),style:B,ref:t},y),L(v)?i.createElement(_,Object.assign({},v,{hasSelectionIcon:"multiple"===o,selected:l,disabled:r})):v)})),U=(0,h.om)("tree-list"),W=({qa:e,id:t,size:n="m",className:s,list:a,multiple:d,containerRef:l,renderItem:r,renderContainer:o=O,onItemClick:u,mapItemDataToContentProps:m})=>{const p=(0,c.u)(),I=null!==t&&void 0!==t?t:p,v=i.useRef(null),b=null!==l&&void 0!==l?l:v,g=i.useMemo((()=>{if(null===u)return;return(e,t)=>{const n={id:e.id,list:a};if(u)null===u||void 0===u||u(n,t);else{w({list:a,multiple:d})(n,t)}}}),[u,a,d]);R({containerRef:b,onItemClick:g,list:a});return o({qa:e,id:`list-${I}`,size:n,containerRef:b,className:U(null,s),list:a,renderItem:(t,s,l)=>{const o=(({qa:e,list:t,onItemClick:n,mapItemDataToContentProps:i,size:s="m",multiple:a=!1,id:d})=>{var l,r;const o=Object.assign(Object.assign(Object.assign({},t.structure.itemsState[d]),t.structure.groupsState[d]),{isLastItem:d===t.structure.visibleFlattenIds[t.structure.visibleFlattenIds.length-1]}),c={id:d,size:s,selected:Boolean(t.state.selectedById[d]),disabled:Boolean(null===(l=t.state.disabledById)||void 0===l?void 0:l[d]),active:d===t.state.activeItemId,onClick:n?e=>n({id:d},e):void 0,selectionViewType:Boolean(a)&&!o.childrenIds?"multiple":"single",content:Object.assign({expanded:null===(r=t.state.expandedById)||void 0===r?void 0:r[d],indentation:o.indentation,isGroup:t.state.expandedById&&d in t.state.expandedById},i(t.structure.itemsById[d]))};return e&&(c.qa=((e,t)=>`${e}-${t}`)(e,d)),{data:t.structure.itemsById[d],props:c,context:o}})({qa:e,id:t,size:n,multiple:d,mapItemDataToContentProps:m,onItemClick:g,list:a});return r?r({id:t,data:o.data,props:o.props,context:o.context,index:s,renderContainerProps:l,list:a}):i.createElement(V,Object.assign({},o.props,l))}})};var H=n(63246),J=n(34379),G=n(46819);const Y=({item:e,groupedId:t,getItemId:n})=>{let i=t;return"function"===typeof n?i=n(B(e)?e.data:e):e&&"object"===typeof e&&"id"in e&&e.id&&(i=e.id),i},K=(e,t)=>t?`${t}-${e}`:`${e}`;function Q({items:e,expandedById:t,getItemId:n}){const s=i.useMemo((()=>function({items:e,getItemId:t,expandedById:n={}}){const i=[],s=(e,a,d,l)=>{const r=K(d,l),o=Y({groupedId:r,item:a,getItemId:t});return l||i.push(o),e.push(o),B(a)&&a.children&&(o in n&&!n[o]||e.push(...a.children.reduce(((e,t,n)=>s(e,t,n,o)),[]))),e},a=e.reduce(((e,t,n)=>s(e,t,n)),[]),d={};for(const[l,r]of a.entries())d[r]=l;return{rootIds:i,visibleFlattenIds:a,idToFlattenIndex:d}}({items:e,expandedById:t,getItemId:n})),[e,t,n]);return s}function X({items:e,defaultExpandedState:t="expanded",getItemId:n}){const i={itemsById:{},groupsState:{},itemsState:{},initialState:{disabledById:{},selectedById:{},expandedById:{}}},s=({item:e,index:a,parentGroupedId:d,parentId:l})=>{const r=K(a,d),o=Y({groupedId:r,item:e,getItemId:n});l&&i.groupsState[l].childrenIds.push(o),i.itemsById[o]=e.data,i.itemsState[o]||(i.itemsState[o]={indentation:0}),"undefined"!==typeof l&&(i.itemsState[o].parentId=l),"undefined"!==typeof e.selected&&(i.initialState.selectedById[o]=e.selected),"undefined"!==typeof e.disabled&&(i.initialState.disabledById[o]=e.disabled),r&&(i.itemsState[o].indentation=(e=>e.split("-"))(r).length-1),e.children&&(i.groupsState[o]={childrenIds:[]},i.initialState.expandedById&&("undefined"===typeof e.expanded?i.initialState.expandedById[o]="expanded"===t:i.initialState.expandedById[o]=e.expanded),e.children.forEach(((e,t)=>{s({item:e,index:t,parentGroupedId:r,parentId:o})})))};return e.forEach(((e,t)=>B(e)?s({item:e,index:t}):(({item:e,index:t})=>{const s=Y({groupedId:String(t),item:e,getItemId:n});i.itemsById[s]=e,i.itemsState[s]||(i.itemsState[s]={indentation:0}),e&&"object"===typeof e&&("selected"in e&&"boolean"===typeof e.selected&&(i.initialState.selectedById[s]=e.selected),"disabled"in e&&"boolean"===typeof e.disabled&&(i.initialState.disabledById[s]=e.disabled))})({item:e,index:t}))),i}const Z=({items:e,getItemId:t,defaultExpandedState:n="expanded",withExpandedState:s=!0,initialState:a,controlledState:d})=>{const{itemsById:l,groupsState:r,itemsState:o,initialState:c}=function({items:e,getItemId:t,defaultExpandedState:n}){const s=i.useRef(t).current;return i.useMemo((()=>X({items:e,getItemId:s,defaultExpandedState:n})),[s,n,e])}({items:e,getItemId:t,defaultExpandedState:n}),u=(({initialState:e,withExpandedState:t})=>{const n=i.useRef(e),s=n.current!==e;n.current=e;const[a,d]=i.useState((()=>{var t;return null!==(t=null===e||void 0===e?void 0:e.disabledById)&&void 0!==t?t:{}})),[l,r]=i.useState((()=>{var t;return null!==(t=null===e||void 0===e?void 0:e.selectedById)&&void 0!==t?t:{}})),[o,c]=i.useState((()=>{var t;return null!==(t=null===e||void 0===e?void 0:e.expandedById)&&void 0!==t?t:{}})),[u,m]=i.useState((()=>null===e||void 0===e?void 0:e.activeItemId));s&&((null===e||void 0===e?void 0:e.disabledById)&&d((t=>Object.assign(Object.assign({},e.disabledById),t))),(null===e||void 0===e?void 0:e.selectedById)&&r((t=>Object.assign(Object.assign({},e.selectedById),t))),(null===e||void 0===e?void 0:e.expandedById)&&c((t=>Object.assign(Object.assign({},e.expandedById),t))),m((t=>null!==t&&void 0!==t?t:null===e||void 0===e?void 0:e.activeItemId)));const p={disabledById:a,selectedById:l,activeItemId:u,setDisabled:d,setSelected:r,setActiveItemId:m};return t&&(p.expandedById=o,p.setExpanded=c),p})({initialState:i.useMemo((()=>({expandedById:Object.assign(Object.assign({},c.expandedById),null===a||void 0===a?void 0:a.expandedById),selectedById:Object.assign(Object.assign({},c.selectedById),null===a||void 0===a?void 0:a.selectedById),disabledById:Object.assign(Object.assign({},c.disabledById),null===a||void 0===a?void 0:a.disabledById),activeItemId:null===a||void 0===a?void 0:a.activeItemId})),[c.disabledById,c.expandedById,c.selectedById,null===a||void 0===a?void 0:a.activeItemId,null===a||void 0===a?void 0:a.disabledById,null===a||void 0===a?void 0:a.expandedById,null===a||void 0===a?void 0:a.selectedById]),withExpandedState:s}),m=i.useMemo((()=>d?Object.assign(Object.assign({},u),d):u),[d,u]),{visibleFlattenIds:p,idToFlattenIndex:I,rootIds:v}=Q({items:e,expandedById:m.expandedById,getItemId:t});return{state:m,structure:{rootIds:v,items:e,visibleFlattenIds:p,idToFlattenIndex:I,itemsById:l,groupsState:r,itemsState:o}}},ee=({defaultValue:e=[],value:t,onUpdate:n})=>{const[s,a]=i.useState(e),d=null!==t&&void 0!==t?t:s,l=!t;return i.useMemo((()=>{const e=d.reduce(((e,t)=>(e[t]=!0,e)),{});return{value:d,selectedById:e,setSelected:t=>{const i=(e=>Object.entries(e).reduce(((e,[t,n])=>(n&&e.push(t),e)),[]))("function"===typeof t?t(e):t);l?a(i):null===n||void 0===n||n(i)},setInnerValue:l?a:void 0}}),[n,l,d])},te=(0,h.om)("tree-select"),ne=e=>i.createElement(V,Object.assign({},e.props,e.renderContainerProps)),ie=i.forwardRef((function({id:e,qa:t,title:n,placement:s,slotBeforeListBody:a,slotAfterListBody:d,size:l="m",defaultOpen:r,width:o,containerRef:u,className:m,containerClassName:f,popupClassName:y,open:h,multiple:x,popupWidth:S,popupDisablePortal:B,items:E,value:C,defaultValue:O,placeholder:j,disabled:k=!1,withExpandedState:N=!0,defaultExpandedState:R="expanded",hasClear:D,errorMessage:F,errorPlacement:P,validationState:T,onClose:$,onOpenChange:A,onUpdate:z,renderControl:M,renderItem:L=ne,renderContainer:q,mapItemDataToContentProps:_,onFocus:V,onBlur:U,getItemId:Y,onItemClick:K},Q){const X=(0,G.I)(),ie=(0,c.u)(),se=null!==e&&void 0!==e?e:ie,ae=`tree-select-popup-${se}`,de=i.useRef(null),le=i.useRef(null),re=i.useRef(null),oe=null!==u&&void 0!==u?u:re,{errorMessage:ce,errorPlacement:ue,validationState:me}=(0,J.Av)({errorMessage:F,errorPlacement:P||"outside",validationState:T}),pe=(0,c.u)(),Ie="invalid"===me,ve=Ie&&Boolean(ce)&&"outside"===ue,be=Ie&&Boolean(ce)&&"inside"===ue,ge=(0,p.N)(Q,le),{toggleOpen:fe,open:ye}=(0,v.F)({defaultOpen:r,onClose:$,onOpenChange:A,open:h}),{value:he,selectedById:xe,setSelected:Se}=ee({value:C,defaultValue:O,onUpdate:z}),Be=Z({controlledState:{selectedById:xe,setSelected:Se},items:E,getItemId:Y,defaultExpandedState:R,withExpandedState:N}),Ee=i.useMemo((()=>{if(null===K)return;return(e,t)=>{const n={id:e.id,list:Be};if(K)null===K||void 0===K||K(n,t);else{w({list:Be,multiple:x})(n,t);const i=Be.state.expandedById&&e.id in Be.state.expandedById;x||i||fe(!1)}}}),[K,Be,x,fe]);i.useLayoutEffect((()=>{var e;return ye&&(null===(e=oe.current)||void 0===e||e.focus({preventScroll:!0})),()=>Be.state.setActiveItemId(void 0)}),[ye]);const Ce=i.useCallback((()=>fe(!1)),[fe]),{focusWithinProps:Oe}=(0,I.R)({onFocusWithin:V,onBlurWithin:i.useCallback((e=>{null===U||void 0===U||U(e),Ce()}),[Ce,U])}),we={list:Be,open:ye,placeholder:j,toggleOpen:fe,clearValue:()=>Be.state.setSelected({}),ref:ge,size:l,value:he,disabled:k,id:se,activeItemId:Be.state.activeItemId,title:n,errorMessage:be?ce:void 0,errorPlacement:ue,validationState:me,hasClear:D,isErrorVisible:Ie},je=M?M(we):i.createElement(b.Y,Object.assign({},we,{selectedOptionsContent:i.Children.toArray(he.map((e=>e in Be.structure.itemsById?_(Be.structure.itemsById[e]).title:""))).join(", "),view:"normal",pin:"round-round",popupId:ae,selectId:se})),ke=Object.assign({},"max"===o&&{width:o}),Ne={};return"number"===typeof o&&(Ne.width=o),i.createElement("div",Object.assign({ref:de},Oe,{className:te(ke,m),style:Ne}),je,i.createElement(g.t,{ref:de,className:te("popup",{size:l},y),controlRef:le,width:S,placement:s,open:ye,handleClose:Ce,disablePortal:B,mobile:X,id:ae},a,i.createElement(W,{list:Be,size:l,className:te("list",f),qa:t,multiple:x,id:`list-${se}`,containerRef:oe,onItemClick:Ee,renderContainer:q,mapItemDataToContentProps:_,renderItem:null!==L&&void 0!==L?L:ne}),d),i.createElement(H.o,{errorMessage:ve?ce:null,errorMessageId:pe}))}));var se=n(28664),ae=n(43781),de=n.n(ae);function le(e,t){return!t||"object"!==typeof t||!("title"in t)||"string"!==typeof t.title||t.title.toLowerCase().includes((e||"").toLowerCase())}function re({items:e,initialFilterValue:t="",filterItem:n,onFilterChange:s,filterItems:a,debounceTimeout:d=300}){const l=i.useRef(null),[r,o]=i.useState(t),[c,u]=i.useState(e),[m,p]=i.useState(e),I=i.useCallback(((e,t)=>{if(a)return()=>a(e,t);if(e){const i=n||le;return()=>function(e,t){const n=(e,i)=>{if(B(i)&&i.children){const s=i.children.reduce(n,[]);s.length?e.push(Object.assign(Object.assign({},i),{data:i.data,children:s})):t(i.data)&&e.push(Object.assign(Object.assign({},i),{data:i.data,children:[]}))}else if(B(i)&&t(i.data)){const{children:t}=i,n=(0,f.Tt)(i,["children"]);e.push(n)}else!B(i)&&t(i)&&e.push(i);return e};return e.reduce(n,[])}(t,(t=>i(e,t)))}return()=>t}),[n,a]);e!==c&&(p(I(r,e)),u(e));const v=i.useCallback(de()((t=>p(I(t,e))),d),[p,I,e,d]),{onFilterUpdate:b,reset:g}=i.useMemo((()=>({reset:()=>{o(t),null===s||void 0===s||s(t),v(t)},onFilterUpdate:e=>{o(e),null===s||void 0===s||s(e),v(e)}})),[v,t,s]);return{filterRef:l,filter:r,reset:g,items:m,onFilterUpdate:b}}var oe=n(72837);const ce=JSON.parse('{"button_apply":"Apply","button_reset":"Reset","button_switcher":"Columns"}'),ue=JSON.parse('{"button_apply":"\u041f\u0440\u0438\u043c\u0435\u043d\u0438\u0442\u044c","button_reset":"\u0421\u0431\u0440\u043e\u0441\u0438\u0442\u044c","button_switcher":"\u041a\u043e\u043b\u043e\u043d\u043a\u0438"}'),me=(0,oe.N)({en:ce,ru:ue},"TableColumnSetupInner"),pe=(0,h.om)("inner-table-column-setup"),Ie=pe("controls"),ve=pe("filter-input"),be=pe("empty-placeholder"),ge={isDragDisabled:!0},fe=e=>({title:e.title}),ye=(e,t)=>"string"!==typeof t.title||t.title.toLowerCase().includes(e.trim().toLowerCase()),he=e=>{const{renderSwitcher:t,popupWidth:n,popupPlacement:p,items:I,onUpdate:v,sortable:b,renderControls:g,className:f,defaultItems:h=I,showResetButton:x,filterable:B,filterPlaceholder:E,filterEmptyMessage:C,filterSettings:O=ye}=e,[w,j]=i.useState(!1),[k,N]=i.useState(b),[R,D]=i.useState(b);b!==R&&(D(b),N(b));const[F,P]=i.useState(I),[T,$]=i.useState(I);I!==T&&($(I),P(I));const A=re({items:F,filterItem:O,debounceTimeout:0}),z=()=>{const e=F.map((({id:e,isSelected:t})=>({id:e,isSelected:t})));v(e),U(!1)},M=()=>i.createElement(a.$,{view:"action",width:"max",onClick:z},me("button_apply")),L="function"===typeof x?x(F):x,q=(({onDragEnd:e,renderControls:t})=>{const n=(0,c.u)();return({renderItem:s,list:a,containerRef:d,id:l,className:r})=>{const{stickyStartItemIdList:c,sortableItemIdList:u,stickyEndItemIdList:m}=((e,t)=>{let n=0;for(;n!==t.length;n++){const i=e[t[n]];if("left"!==(null===i||void 0===i?void 0:i.sticky)&&"start"!==(null===i||void 0===i?void 0:i.sticky))break}let i=t.length;for(;0!==i;i--){const n=e[t[i-1]];if("right"!==(null===n||void 0===n?void 0:n.sticky)&&"end"!==(null===n||void 0===n?void 0:n.sticky))break}return{stickyStartItemIdList:t.slice(0,n),sortableItemIdList:t.slice(n,i),stickyEndItemIdList:t.slice(i)}})(a.structure.itemsById,a.structure.visibleFlattenIds),p=c.map(((e,t)=>s(e,t,ge))),I=u.map(((e,t)=>s(e,t+c.length))),v=m.map(((e,t)=>s(e,p.length+I.length+t,ge)));return i.createElement(i.Fragment,null,i.createElement(S,{ref:d,id:l,className:r},p,i.createElement(o.JY,{onDragEnd:e},i.createElement(o.gL,{droppableId:n,renderClone:(e,t,n)=>{const i={provided:e,snapshot:t};return s(a.structure.visibleFlattenIds[n.source.index],n.source.index,i)}},(e=>i.createElement("div",Object.assign({},e.droppableProps,{ref:e.innerRef}),I,e.placeholder)))),v),i.createElement("div",{className:Ie},t()))}})({onDragEnd:({destination:e,source:t})=>{void 0!==(null===e||void 0===e?void 0:e.index)&&(null===e||void 0===e?void 0:e.index)!==t.index&&P((n=>((e,t,n)=>{const i=[...e],[s]=i.splice(t,1);return i.splice(n,0,s),i})(n,t.index,e.index)))},renderControls:()=>g?g({DefaultApplyButton:M,onApply:z}):i.createElement(y.s,{gapRow:1,direction:"column",className:Ie},L&&i.createElement(a.$,{onClick:()=>{P(h)},width:"max"},me("button_reset")),i.createElement(M,null))}),_=(e=>({data:t,props:n,index:s,renderContainerProps:a})=>{const c=!1===e||!0===(null===a||void 0===a?void 0:a.isDragDisabled),u=c?void 0:i.createElement(d.I,{data:l.A,size:16}),m=t.isRequired?i.createElement(d.I,{data:r}):void 0,p=!t.isRequired&&n.selected,I=Object.assign(Object.assign({},n),{selected:p,selectionViewType:t.isRequired?"single":"multiple",content:Object.assign(Object.assign({},n.content),{startSlot:m,endSlot:u})});if(c)return i.createElement(V,Object.assign({},I,{key:I.id}));const v=(e,t)=>i.createElement(V,Object.assign({},I,e.draggableProps,e.dragHandleProps,{ref:e.innerRef,dragging:t.isDragging}));return(null===a||void 0===a?void 0:a.provided)&&a.snapshot?v(a.provided,a.snapshot):i.createElement(o.sx,{draggableId:n.id,index:s,key:`item-key-${n.id}`,isDragDisabled:c},v)})(k),U=e=>{j(e),!1===e&&(P(I),N(b),A.reset())},W=i.useMemo((()=>(e=>{const t=[];return e.forEach((({id:e,isSelected:n})=>{n&&t.push(e)})),t})(F)),[F]),H=(J=C,()=>i.createElement(m.E,{className:be},J));var J;const G=B?i.createElement(se.k,{size:"m",view:"clear",placeholder:E,value:A.filter,className:ve,onUpdate:e=>{A.onFilterUpdate(e),N(!e.length)},hasClear:!0}):null,Y=A.filter&&!A.items.length?H:q;return i.createElement(ie,{className:pe(null,f),mapItemDataToContentProps:fe,multiple:!0,size:"l",open:w,value:W,items:A.filter?A.items:F,onUpdate:e=>{P((t=>t.map((t=>Object.assign(Object.assign({},t),{isSelected:t.isRequired||e.includes(t.id)})))))},popupWidth:n,onOpenChange:U,placement:p,slotBeforeListBody:G,renderContainer:Y,renderControl:({toggleOpen:e})=>{const n=(0,u.h)(e);return(null===t||void 0===t?void 0:t({onClick:e,onKeyDown:n}))||i.createElement(a.$,{onClick:e,extraProps:{onKeyDown:n}},i.createElement(d.I,{data:s.A}),me("button_switcher"))},renderItem:_})},xe=JSON.parse('{"button_switcher":"Columns"}'),Se=JSON.parse('{"button_switcher":"\u041a\u043e\u043b\u043e\u043d\u043a\u0438"}'),Be=(0,oe.N)({en:xe,ru:Se},"TableColumnSetup"),Ee=(0,h.om)("table-column-setup"),Ce=e=>{const{switcher:t,renderSwitcher:n,disabled:l,popupWidth:r,popupPlacement:o,className:c,items:u,sortable:m=!0,showStatus:p,onUpdate:I}=e,v=u.map((({id:e,title:t,required:n,selected:i,sticky:s})=>({id:e,title:t,isRequired:n,isSelected:i,sticky:s})));return i.createElement(he,{items:v,onUpdate:e=>{I(e.map((({id:e,isSelected:t})=>{const n=u.find((t=>t.id===e));return{id:e,selected:t,title:null===n||void 0===n?void 0:n.title,required:null===n||void 0===n?void 0:n.required}})))},popupPlacement:o,popupWidth:r,renderSwitcher:e=>(null===n||void 0===n?void 0:n(e))||t||i.createElement(a.$,{disabled:l,onClick:e.onClick},i.createElement(d.I,{data:s.A}),Be("button_switcher"),(()=>{if(!p)return null;const e=`${u.reduce(((e,t)=>t.selected?e+1:e),0)}/${u.length}`;return i.createElement("span",{className:Ee("status")},e)})()),sortable:m,className:Ee(null,c)})}},38501:(e,t,n)=>{"use strict";n.d(t,{D:()=>s});var i=n(46878);function s(){return(0,i.w)().theme}},23536:(e,t,n)=>{var i=n(68814),s=/[\\^$.*+?()[\]{}|]/g,a=RegExp(s.source);e.exports=function(e){return(e=i(e))&&a.test(e)?e.replace(s,"\\$&"):e}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4169.f2243012.chunk.js b/ydb/core/viewer/monitoring/static/js/4169.f2243012.chunk.js deleted file mode 100644 index b41473e07e0b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4169.f2243012.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4169],{34169:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),o={name:"pt",weekdays:"domingo_segunda-feira_ter\xe7a-feira_quarta-feira_quinta-feira_sexta-feira_s\xe1bado".split("_"),weekdaysShort:"dom_seg_ter_qua_qui_sex_sab".split("_"),weekdaysMin:"Do_2\xaa_3\xaa_4\xaa_5\xaa_6\xaa_Sa".split("_"),months:"janeiro_fevereiro_mar\xe7o_abril_maio_junho_julho_agosto_setembro_outubro_novembro_dezembro".split("_"),monthsShort:"jan_fev_mar_abr_mai_jun_jul_ago_set_out_nov_dez".split("_"),ordinal:function(e){return e+"\xba"},weekStart:1,yearStart:4,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY [\xe0s] HH:mm",LLLL:"dddd, D [de] MMMM [de] YYYY [\xe0s] HH:mm"},relativeTime:{future:"em %s",past:"h\xe1 %s",s:"alguns segundos",m:"um minuto",mm:"%d minutos",h:"uma hora",hh:"%d horas",d:"um dia",dd:"%d dias",M:"um m\xeas",MM:"%d meses",y:"um ano",yy:"%d anos"}};return _.default.locale(o,null,!0),o}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/41696.f9f2ec5d.chunk.js b/ydb/core/viewer/monitoring/static/js/41696.f9f2ec5d.chunk.js new file mode 100644 index 000000000000..8a835e81c409 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/41696.f9f2ec5d.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[41696],{41696:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e),a={s:"ein paar Sekunden",m:["eine Minute","einer Minute"],mm:"%d Minuten",h:["eine Stunde","einer Stunde"],hh:"%d Stunden",d:["ein Tag","einem Tag"],dd:["%d Tage","%d Tagen"],M:["ein Monat","einem Monat"],MM:["%d Monate","%d Monaten"],y:["ein Jahr","einem Jahr"],yy:["%d Jahre","%d Jahren"]};function i(e,n,t){var i=a[t];return Array.isArray(i)&&(i=i[n?0:1]),i.replace("%d",e)}var _={name:"de-ch",weekdays:"Sonntag_Montag_Dienstag_Mittwoch_Donnerstag_Freitag_Samstag".split("_"),weekdaysShort:"So_Mo_Di_Mi_Do_Fr_Sa".split("_"),weekdaysMin:"So_Mo_Di_Mi_Do_Fr_Sa".split("_"),months:"Januar_Februar_M\xe4rz_April_Mai_Juni_Juli_August_September_Oktober_November_Dezember".split("_"),monthsShort:"Jan._Feb._M\xe4rz_Apr._Mai_Juni_Juli_Aug._Sep._Okt._Nov._Dez.".split("_"),ordinal:function(e){return e+"."},weekStart:1,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY HH:mm",LLLL:"dddd, D. MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"vor %s",s:i,m:i,mm:i,h:i,hh:i,d:i,dd:i,M:i,MM:i,y:i,yy:i}};return t.default.locale(_,null,!0),_}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4187.ab11fc96.chunk.js b/ydb/core/viewer/monitoring/static/js/4187.ab11fc96.chunk.js deleted file mode 100644 index 3cb66893c4f7..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4187.ab11fc96.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4187],{79737:(e,t,a)=>{"use strict";a.d(t,{A:()=>o,X:()=>l});var n=a(5874),r=a(77506),s=a(60712);const i=(0,r.cn)("ydb-table");function o({children:e,className:t}){return(0,s.jsx)("div",{className:i("table-header-content",t),children:e})}function l({className:e,width:t,wrapperClassName:a,...r}){return(0,s.jsx)("div",{className:i(null,a),children:(0,s.jsx)(n.W,{headerCellClassName:({column:e})=>{var t;const a=null===(t=e.columnDef.meta)||void 0===t?void 0:t.align;return i("table-header-cell",{align:a})},cellClassName:e=>{var t,a;const n=null===e||void 0===e||null===(t=e.column.columnDef.meta)||void 0===t?void 0:t.align,r=null===e||void 0===e||null===(a=e.column.columnDef.meta)||void 0===a?void 0:a.verticalAlign;return i("table-cell",{align:n,"vertical-align":r})},className:i("table",{width:t},e),...r})})}},8300:(e,t,a)=>{"use strict";a.d(t,{BB:()=>i,TL:()=>l,XT:()=>o});var n=a(43733),r=a(32138),s=a(62422);const i={...r.A,'pre[class*="language-"]':{...r.A['pre[class*="language-"]'],background:"transparent",margin:0},'code[class*="language-"]':{...r.A['code[class*="language-"]'],background:"transparent",color:"var(--g-color-text-primary)",whiteSpace:"pre-wrap"},comment:{color:"#969896"},string:{color:"#a31515"},tablepath:{color:"#338186"},function:{color:"#7a3e9d"},udf:{color:"#7a3e9d"},type:{color:"#4d932d"},boolean:{color:"#608b4e"},constant:{color:"#608b4e"},variable:{color:"#001188"}},o={...s.A,'pre[class*="language-"]':{...s.A['pre[class*="language-"]'],background:"transparent",margin:0},'code[class*="language-"]':{...s.A['code[class*="language-"]'],background:"transparent",color:"var(--g-color-text-primary)",whiteSpace:"pre-wrap"},comment:{color:"#969896"},string:{color:"#ce9178"},tablepath:{color:"#338186"},function:{color:"#9e7bb0"},udf:{color:"#9e7bb0"},type:{color:"#6A8759"},boolean:{color:"#608b4e"},constant:{color:"#608b4e"},variable:{color:"#74b0df"}};function l(e){e.languages.yql={comment:[{pattern:/--.*$/m,greedy:!0},{pattern:/\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0}],tablepath:{pattern:/(`[\w/]+`\s*\.\s*)?`[^`]+`/,greedy:!0},string:[{pattern:/'(?:\\[\s\S]|[^\\'])*'/,greedy:!0},{pattern:/"(?:\\[\s\S]|[^\\"])*"/,greedy:!0},{pattern:/@@(?:[^@]|@(?!@))*@@/,greedy:!0}],variable:[{pattern:/\$[a-zA-Z_]\w*/,greedy:!0}],function:{pattern:new RegExp(`\\b(?:${n.XB.join("|")})\\b`,"i"),greedy:!0},keyword:{pattern:new RegExp(`\\b(?:${n.RE.join("|")})\\b`,"i"),greedy:!0},udf:{pattern:/[A-Za-z_]\w*::[A-Za-z_]\w*/,greedy:!0},type:{pattern:new RegExp(`\\b(?:${n.to.join("|")})\\b`,"i"),greedy:!0},boolean:{pattern:/\b(?:true|false|null)\b/i,greedy:!0},number:{pattern:/[+-]?(?:\d+(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?/i,greedy:!0},operator:{pattern:/[-+*/%<>!=&|^~]+|\b(?:and|or|not|is|like|ilike|rlike|in|between)\b/i,greedy:!0},punctuation:{pattern:/[;[\](){}.,]/,greedy:!0}}}l.displayName="yql",l.aliases=["yql"]},76768:(e,t,a)=>{"use strict";a.d(t,{C:()=>b});var n=a(44992),r=a(44508),s=a(53850),i=a(62060),o=a.n(i),l=a(21334),c=a(24600);const d=l.F.injectEndpoints({endpoints:e=>({getTabletsInfo:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.viewer.getTabletsInfo(e,{signal:t})}}catch(a){return{error:a}}},providesTags:["All",{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"}),u=(0,s.Mz)((e=>e),(e=>d.endpoints.getTabletsInfo.select(e)),{argsMemoize:s.i5,argsMemoizeOptions:{equalityCheck:o()}}),m=(0,s.Mz)((e=>e),((e,t)=>u(t)),((e,t)=>t(e).data)),p=(0,s.Mz)(((e,t)=>m(e,t)),(e=>(0,c.K)(e)),((e,t)=>null!==e&&void 0!==e&&e.TabletStateInfo?t?e.TabletStateInfo.map((e=>{var a;const n=void 0===e.NodeId||null===(a=t.get(e.NodeId))||void 0===a?void 0:a.Host;return{...e,fqdn:n}})):e.TabletStateInfo:[]));var h=a(77506),v=a(90182),g=a(88616),y=a(60712);const x=(0,h.cn)("tablets");function b({nodeId:e,path:t,database:a,className:s}){const[i]=(0,v.Nt)();let o={};const l=void 0===e?void 0:String(e);void 0!==l?o={nodeId:l,database:a}:t&&(o={path:t,database:a});const{currentData:c,isFetching:u,error:m}=d.useGetTabletsInfoQuery(0===Object.keys(o).length?n.hT:o,{pollingInterval:i}),h=u&&void 0===c,b=(0,v.N4)((e=>p(e,o)));return(0,y.jsxs)("div",{className:x(null,s),children:[m?(0,y.jsx)(r.o,{error:m}):null,c||h?(0,y.jsx)(g.Q,{tablets:b,database:a,loading:h}):null]})}},16516:(e,t,a)=>{"use strict";a.r(t),a.d(t,{Tenant:()=>ag});var n=a(59284),r=a(61750),s=a(67087),i=a(64689),o=a(98167),l=a(61283),c=a(77506),d=a(60712);const u=(0,c.cn)("kv-split"),m=[0,100],p=[50,50];const h=function(e){const[t,a]=n.useState(),r=t=>{const{defaultSizePaneKey:a}=e;localStorage.setItem(a,t.join(","))};return n.useEffect((()=>{const{collapsedSizes:t,triggerCollapse:n}=e;if(n){const e=t||m;r(e),a(e)}}),[e.triggerCollapse]),n.useEffect((()=>{const{triggerExpand:t,defaultSizes:n}=e,s=n||p;t&&(r(s),a(s))}),[e.triggerExpand]),(0,d.jsx)(n.Fragment,{children:(0,d.jsx)(l.A,{direction:e.direction||"horizontal",sizes:t||(()=>{var t;const{defaultSizePaneKey:a,defaultSizes:n=p,initialSizes:r}=e;if(r)return r;return(null===(t=localStorage.getItem(a))||void 0===t?void 0:t.split(",").map(Number))||n})(),minSize:e.minSize||[0,0],onDrag:t=>{const{onSplitDragAdditional:a}=e;a&&a(),r(t)},className:u(null,e.direction||"horizontal"),gutterSize:8,onDragStart:()=>{const{onSplitStartDragAdditional:t}=e;t&&t(),a(void 0)},expandToMin:!0,children:e.children})})};var v=a(40174),g=a(53850),y=a(44992);let x=function(e){return e.EPathTypeInvalid="EPathTypeInvalid",e.EPathTypeDir="EPathTypeDir",e.EPathTypeTable="EPathTypeTable",e.EPathTypePersQueueGroup="EPathTypePersQueueGroup",e.EPathTypeSubDomain="EPathTypeSubDomain",e.EPathTypeTableIndex="EPathTypeTableIndex",e.EPathTypeExtSubDomain="EPathTypeExtSubDomain",e.EPathTypeColumnStore="EPathTypeColumnStore",e.EPathTypeColumnTable="EPathTypeColumnTable",e.EPathTypeCdcStream="EPathTypeCdcStream",e.EPathTypeExternalDataSource="EPathTypeExternalDataSource",e.EPathTypeExternalTable="EPathTypeExternalTable",e.EPathTypeView="EPathTypeView",e.EPathTypeReplication="EPathTypeReplication",e}({}),b=function(e){return e.EPathSubTypeEmpty="EPathSubTypeEmpty",e.EPathSubTypeSyncIndexImplTable="EPathSubTypeSyncIndexImplTable",e.EPathSubTypeAsyncIndexImplTable="EPathSubTypeAsyncIndexImplTable",e.EPathSubTypeStreamImpl="EPathSubTypeStreamImpl",e}({});let f=function(e){return e.ColumnCodecPlain="ColumnCodecPlain",e.ColumnCodecLZ4="ColumnCodecLZ4",e.ColumnCodecZSTD="ColumnCodecZSTD",e}({});let j=function(e){return e.METERING_MODE_RESERVED_CAPACITY="METERING_MODE_RESERVED_CAPACITY",e.METERING_MODE_REQUEST_UNITS="METERING_MODE_REQUEST_UNITS",e}({});const S={[b.EPathSubTypeSyncIndexImplTable]:"index_table",[b.EPathSubTypeAsyncIndexImplTable]:"index_table",[b.EPathSubTypeStreamImpl]:void 0,[b.EPathSubTypeEmpty]:void 0},T={[x.EPathTypeInvalid]:void 0,[x.EPathTypeSubDomain]:"database",[x.EPathTypeExtSubDomain]:"database",[x.EPathTypeDir]:"directory",[x.EPathTypeColumnStore]:"directory",[x.EPathTypeTable]:"table",[x.EPathTypeTableIndex]:"index",[x.EPathTypeColumnTable]:"column_table",[x.EPathTypeCdcStream]:"stream",[x.EPathTypePersQueueGroup]:"topic",[x.EPathTypeExternalDataSource]:"external_data_source",[x.EPathTypeExternalTable]:"external_table",[x.EPathTypeView]:"view",[x.EPathTypeReplication]:"async_replication"},N={table:x.EPathTypeTable,index:x.EPathTypeTableIndex,column_table:x.EPathTypeColumnTable,external_table:x.EPathTypeExternalTable,view:x.EPathTypeView},E=(e=x.EPathTypeDir,t,a="directory")=>t&&S[t]||T[e]||a,w={[b.EPathSubTypeSyncIndexImplTable]:"Secondary Index Table",[b.EPathSubTypeAsyncIndexImplTable]:"Secondary Index Table",[b.EPathSubTypeStreamImpl]:void 0,[b.EPathSubTypeEmpty]:void 0},C={[x.EPathTypeInvalid]:void 0,[x.EPathTypeSubDomain]:"Database",[x.EPathTypeExtSubDomain]:"Database",[x.EPathTypeDir]:"Directory",[x.EPathTypeTable]:"Table",[x.EPathTypeTableIndex]:"Secondary Index",[x.EPathTypeColumnStore]:"Tablestore",[x.EPathTypeColumnTable]:"Column-oriented table",[x.EPathTypeCdcStream]:"Changefeed",[x.EPathTypePersQueueGroup]:"Topic",[x.EPathTypeExternalDataSource]:"External Data Source",[x.EPathTypeExternalTable]:"External Table",[x.EPathTypeView]:"View",[x.EPathTypeReplication]:"Async Replication"},P={UnknownTenantType:"Database",Domain:"Cluster Root",Dedicated:"Dedicated Database",Shared:"Shared Database",Serverless:"Serverless Database"},I={[x.EPathTypeTable]:!0,[x.EPathTypeColumnTable]:!0,[x.EPathTypeExternalTable]:!0,[x.EPathTypeView]:!0,[x.EPathTypeInvalid]:!1,[x.EPathTypeDir]:!1,[x.EPathTypeSubDomain]:!1,[x.EPathTypeTableIndex]:!1,[x.EPathTypeExtSubDomain]:!1,[x.EPathTypeColumnStore]:!1,[x.EPathTypeCdcStream]:!1,[x.EPathTypePersQueueGroup]:!1,[x.EPathTypeExternalDataSource]:!1,[x.EPathTypeReplication]:!1},D=e=>{var t;return null!==(t=e&&I[e])&&void 0!==t&&t},A={[b.EPathSubTypeSyncIndexImplTable]:!0,[b.EPathSubTypeAsyncIndexImplTable]:!0,[b.EPathSubTypeStreamImpl]:!1,[b.EPathSubTypeEmpty]:!1},_=e=>{var t;return null!==(t=e&&A[e])&&void 0!==t&&t},R={[x.EPathTypeColumnStore]:!0,[x.EPathTypeColumnTable]:!0,[x.EPathTypeInvalid]:!1,[x.EPathTypeDir]:!1,[x.EPathTypeTable]:!1,[x.EPathTypeSubDomain]:!1,[x.EPathTypeTableIndex]:!1,[x.EPathTypeExtSubDomain]:!1,[x.EPathTypeCdcStream]:!1,[x.EPathTypePersQueueGroup]:!1,[x.EPathTypeExternalDataSource]:!1,[x.EPathTypeExternalTable]:!1,[x.EPathTypeView]:!1,[x.EPathTypeReplication]:!1},k=e=>{var t;return null!==(t=e&&R[e])&&void 0!==t&&t},O={[x.EPathTypeSubDomain]:!0,[x.EPathTypeExtSubDomain]:!0,[x.EPathTypeInvalid]:!1,[x.EPathTypeDir]:!1,[x.EPathTypeColumnStore]:!1,[x.EPathTypeColumnTable]:!1,[x.EPathTypeTable]:!1,[x.EPathTypeTableIndex]:!1,[x.EPathTypeCdcStream]:!1,[x.EPathTypePersQueueGroup]:!1,[x.EPathTypeExternalDataSource]:!1,[x.EPathTypeExternalTable]:!1,[x.EPathTypeView]:!1,[x.EPathTypeReplication]:!1},M=e=>{var t;return null!==(t=e&&O[e])&&void 0!==t&&t},L={[x.EPathTypeCdcStream]:!0,[x.EPathTypePersQueueGroup]:!1,[x.EPathTypeInvalid]:!1,[x.EPathTypeColumnStore]:!1,[x.EPathTypeColumnTable]:!1,[x.EPathTypeDir]:!1,[x.EPathTypeTable]:!1,[x.EPathTypeSubDomain]:!1,[x.EPathTypeTableIndex]:!1,[x.EPathTypeExtSubDomain]:!1,[x.EPathTypeExternalDataSource]:!1,[x.EPathTypeExternalTable]:!1,[x.EPathTypeView]:!1,[x.EPathTypeReplication]:!1},z=e=>{var t;return null!==(t=e&&L[e])&&void 0!==t&&t},F={[b.EPathSubTypeSyncIndexImplTable]:!0,[b.EPathSubTypeAsyncIndexImplTable]:!0,[b.EPathSubTypeStreamImpl]:!1,[b.EPathSubTypeEmpty]:!1},q={[x.EPathTypeCdcStream]:!0,[x.EPathTypePersQueueGroup]:!0,[x.EPathTypeExternalDataSource]:!0,[x.EPathTypeExternalTable]:!0,[x.EPathTypeView]:!0,[x.EPathTypeReplication]:!0,[x.EPathTypeInvalid]:!1,[x.EPathTypeColumnStore]:!1,[x.EPathTypeColumnTable]:!1,[x.EPathTypeDir]:!1,[x.EPathTypeTable]:!1,[x.EPathTypeSubDomain]:!1,[x.EPathTypeTableIndex]:!1,[x.EPathTypeExtSubDomain]:!1},Q=(e,t)=>{var a;return null!==(a=t&&F[t]||e&&q[e])&&void 0!==a&&a},U=e=>e===x.EPathTypeExternalTable,B=e=>e===x.EPathTypeTable,$=e=>e===x.EPathTypeView;var H=a(21334);const G=H.F.injectEndpoints({endpoints:e=>({getMultiOverview:e.query({queryFn:async({paths:e,database:t},{signal:a})=>{try{return{data:await Promise.all(e.map((e=>window.api.viewer.getDescribe({path:e,database:t},{signal:a}))))}}catch(n){return{error:n}}},keepUnusedDataFor:0,providesTags:["All"]}),getOverview:e.query({queryFn:async({path:e,database:t,timeout:a},{signal:n})=>{try{return{data:await window.api.viewer.getDescribe({path:e,database:t,timeout:a},{signal:n})}}catch(r){return{error:r}}},keepUnusedDataFor:0,providesTags:["All"]})})}),W=(0,g.Mz)((e=>e),((e,t)=>t),((e,t)=>G.endpoints.getOverview.select({path:e,database:t}))),V=(0,g.Mz)((e=>e),((e,t,a)=>W(t,a)),((e,t)=>t(e).data)),J=(0,g.Mz)([(e,t)=>t,(e,t,a)=>a,(e,t,a,n)=>((e,t,a)=>{var n,r;return null===(n=V(e,t,a))||void 0===n||null===(r=n.PathDescription)||void 0===r?void 0:r.Children})(e,t,n)],((e,t,a)=>z(t)?null===a||void 0===a?void 0:a.map((({Name:t})=>e+"/"+t)):void 0));function Y({paths:e,database:t,autoRefreshInterval:a}){const[n,...r]=e,{currentData:s,isFetching:i,error:o}=G.useGetOverviewQuery({path:n,database:t},{pollingInterval:a}),{currentData:l,isFetching:c,error:d}=G.useGetMultiOverviewQuery(r.length?{paths:r,database:t}:y.hT,{pollingInterval:a});return{loading:i&&void 0===s||c&&void 0===l,error:o||d,mergedDescribe:[s,...null!==l&&void 0!==l?l:[]].reduce(((e,t)=>(null!==t&&void 0!==t&&t.Path&&(e[t.Path]=t),e)),{})}}var K=a(29078),Z=a(76086),X=a(90182),ee=a(81288),te=a(22680),ae=a(52531),ne=a(23871),re=a(52905),se=a(90053),ie=a(67028),oe=a(18517),le=a(24555),ce=a(74321),de=a(44508),ue=a(52248),me=a(90565),pe=a(49818),he=a(56839),ve=a(61758),ge=a.n(ve),ye=a(92459),xe=a(58351);const be=(0,c.cn)("heatmap"),fe={width:0,height:0},je=10,Se=e=>{const[t,a]=n.useState(fe),{tablets:r}=e,s=n.useRef(null),i=n.useRef(null);n.useEffect((()=>{const e=s.current,a=e.getContext("2d");a.clearRect(0,0,e.offsetWidth,e.offsetHeight),r.map(function(e){return(a,n)=>{const{columnsCount:r}=t,s=n%r*12,i=12*Math.floor(n/r);e.fillStyle=a.color||"grey",e.fillRect(s,i,je,je)}}(a))})),n.useLayoutEffect((()=>{const e=i.current;if(e){const t=e.offsetWidth-15,n=Math.floor(t/12),s=Math.ceil(r.length/n);a({width:t,height:12*s,columnsCount:n,rowsCount:s})}}),[]);const o=()=>{let e=s.current,t=0;for(;e;)t+=e.offsetTop,e=e.offsetParent;return t},l=()=>{let e=s.current,t=0;for(;e;)t+=e.offsetLeft,e=e.offsetParent;return t},c=(e,a)=>{const{columnsCount:n}=t,r=Math.floor(e/12);return n*Math.floor(a/12)+r},u=ge()(((t,a)=>{const n=new CustomEvent("scroll");window.dispatchEvent(n);const s=e.parentRef.current,i=t-l()+s.scrollLeft,d=a-o()+s.scrollTop,u=c(i,d),m=r[u];if(m){const n={name:m.currentMetric,value:m.formattedValue};e.showTooltip(void 0,m,"tablet",n,{left:t-20,top:a-20})}else e.hideTooltip()}),20);return(0,d.jsx)("div",{ref:i,className:be("canvas-container"),onMouseLeave:()=>{setTimeout((()=>{e.hideTooltip()}),40)},children:(0,d.jsx)("canvas",{ref:s,width:t.width,height:t.height,onClick:t=>{const a=e.parentRef.current,n=t.clientX-l()+a.scrollLeft,s=t.clientY-o()+a.scrollTop,i=c(n,s),d=r[i];d&&window.open((e=>{const{TabletId:t}=e,a=window.location.hostname,n=(0,ye.DM)(t);return`https://${[a,xe.P8,n].map((e=>e.startsWith("/")?e.slice(1):e)).filter(Boolean).join("/")}`})(d),"_blank")},onMouseMove:e=>u(e.clientX,e.clientY)})})},Te={r:255,g:4,b:0},Ne={r:255,g:219,b:77},Ee={r:59,g:201,b:53},we={CPU:{min:0,max:1e6},Network:{min:0,max:1e9},Storage:{min:0,max:2e9},DataSize:{min:0,max:2e9},RowCount:{min:0},IndexSize:{min:0}},Ce=e=>{const t=e.toString(16);return 1===t.length?`0${t}`:t},Pe=(e,t,a)=>{if(1===e)return[t];if(2===e)return[t,a];const n=(t.r-a.r)/(e-1),r=(t.g-a.g)/(e-1),s=(t.b-a.b)/(e-1),i=[];for(let o=0;o(({r:e,g:t,b:a})=>`#${Ce(e)}${Ce(t)}${Ce(a)}`)(e)))},Ie=e=>{const t=Math.floor(e/2),a=t+1;return[...Pe(e%2===0?t:t+1,Ee,Ne),...Pe(a,Ne,Te).slice(1)]},De=(e,t)=>{const a=new Set,n=we[e]||{};t.forEach((t=>{var n;a.add(Number(null===(n=t.metrics)||void 0===n?void 0:n[e]))})),Number.isInteger(n.min)&&a.add(n.min),Number.isInteger(n.max)&&a.add(n.max);const r=Array.from(a.values()).sort(((e,t)=>e-t));return{min:r[0],max:r[r.length-1]}},Ae=(0,c.cn)("histogram"),_e=e=>{const t=n.useRef(),{data:a={},maxCount:r}=e,{count:s,leftBound:i,rightBound:o,color:l}=a,c=s/r*100;return(0,d.jsx)("div",{ref:t,className:Ae("item"),style:{backgroundColor:l,height:`${c}%`},onMouseEnter:()=>{const a=t.current;e.showTooltip(a,{count:s,leftBound:i,rightBound:o},"histogram")},onMouseLeave:e.hideTooltip})},Re=e=>{const{tablets:t,currentMetric:a}=e,{min:n,max:r}=De(a,t),s=Ie(50),i=(r-n)/50,o=s.map(((e,t)=>({color:e,count:0,leftBound:(0,he.ZV)(n+t*i),rightBound:(0,he.ZV)(n+(t+1)*i)})));let l=0;t.forEach((e=>{var t,n;const r=a&&Number(null===(t=e.metrics)||void 0===t?void 0:t[a]),s=Math.floor(r/i),c=(null===(n=o[s])||void 0===n?void 0:n.count)+1;c>l&&(l=c),o[s]={...o[s],count:c}}));return(0,d.jsx)("div",{className:Ae(),children:(0,d.jsxs)("div",{className:Ae("chart"),children:[Boolean(r)&&o.map(((t,a)=>(0,d.jsx)(_e,{data:t,maxCount:l,showTooltip:e.showTooltip,hideTooltip:e.hideTooltip},a))),(0,d.jsx)("div",{className:Ae("x-min"),children:(0,he.ZV)(n)}),(0,d.jsx)("div",{className:Ae("x-max"),children:(0,he.ZV)(r)}),(0,d.jsx)("div",{className:Ae("y-min"),children:"0"}),(0,d.jsx)("div",{className:Ae("y-max"),children:(0,he.ZV)(l)})]})})},ke=(0,c.cn)("heatmap"),Oe=Ie(500),Me=({path:e,database:t})=>{const a=(0,X.YQ)(),r=n.createRef(),[s]=(0,X.Nt)(),{currentData:i,isFetching:o,error:l}=me.f1.useGetHeatmapTabletsInfoQuery({path:e,database:t},{pollingInterval:s}),c=o&&void 0===i,{tablets:u=[],metrics:m}=i||{},{sort:p,heatmap:h,currentMetric:v}=(0,X.N4)((e=>e.heatmap)),g=(...e)=>{a((0,pe.DK)(...e))},y=()=>{a((0,pe.w7)())},x=e=>{a((0,me.nd)({currentMetric:e[0]}))},b=()=>{a((0,me.nd)({sort:!p}))},f=()=>{a((0,me.nd)({heatmap:!h}))},j=()=>{const{min:e,max:t}=De(v,u),a=u.map((a=>{var n;const r=v&&Number(null===(n=a.metrics)||void 0===n?void 0:n[v]),s=((e,t,a)=>0===a?0:Math.round((e-t)/(a-t)*499))(r,e,t),i=Oe[s];return{...a,color:i,value:r,formattedValue:(0,he.ZV)(r),currentMetric:v}})),n=p?a.sort(((e,t)=>Number(t.value)-Number(e.value))):a;return(0,d.jsx)("div",{ref:r,className:ke("items"),children:(0,d.jsx)(Se,{tablets:n,parentRef:r,showTooltip:g,hideTooltip:y})})};return c?(0,d.jsx)(ue.a,{}):(()=>{const{min:e,max:t}=De(v,u);let a;return l&&!i||(a=h?j():(0,d.jsx)(Re,{tablets:u,currentMetric:v,showTooltip:g,hideTooltip:y})),(0,d.jsxs)("div",{className:ke(),children:[(0,d.jsxs)("div",{className:ke("filters"),children:[(0,d.jsx)(le.l,{className:ke("heatmap-select"),value:v?[v]:[],options:m,onUpdate:x,width:200}),(0,d.jsx)("div",{className:ke("sort-checkbox"),children:(0,d.jsx)(ce.S,{onUpdate:b,checked:p,children:"Sort"})}),(0,d.jsx)("div",{className:ke("histogram-checkbox"),children:(0,d.jsx)(ce.S,{onUpdate:f,checked:h,children:"Heatmap"})}),(0,d.jsxs)("div",{className:ke("limits"),children:[(0,d.jsxs)("div",{className:ke("limits-block"),children:[(0,d.jsx)("div",{className:ke("limits-title"),children:"min:"}),(0,d.jsx)("div",{className:ke("limits-value"),children:Number.isInteger(e)?(0,he.ZV)(e):"\u2014"})]}),(0,d.jsxs)("div",{className:ke("limits-block"),children:[(0,d.jsx)("div",{className:ke("limits-title"),children:"max:"}),(0,d.jsx)("div",{className:ke("limits-value"),children:Number.isInteger(t)?(0,he.ZV)(t):"\u2014"})]}),(0,d.jsxs)("div",{className:ke("limits-block"),children:[(0,d.jsx)("div",{className:ke("limits-title"),children:"count:"}),(0,d.jsx)("div",{className:ke("limits-value"),children:(0,he.ZV)(u.length)})]})]})]}),l?(0,d.jsx)(de.o,{error:l}):null,a]})})()};var Le=a(7117),ze=a(59109),Fe=a(17594),qe=a(89073);const Qe=H.F.injectEndpoints({endpoints:e=>({getOperationList:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.operation.getOperationList(e,{signal:t})}}catch(a){return{error:a}}},providesTags:["All"]}),cancelOperation:e.mutation({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.operation.cancelOperation(e,{signal:t})}}catch(a){return{error:a}}}}),forgetOperation:e.mutation({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.operation.forgetOperation(e,{signal:t})}}catch(a){return{error:a}}}})}),overrideExisting:"throw"});var Ue=a(28539),Be=a(95963),$e=a(48372);const He=JSON.parse('{"label_operations":"Operations","title_empty":"No operations data","pleaceholder_search":"Search operations","placeholder_kind":"Select operation kind","kind_ssBackgrounds":"SS/Backgrounds","kind_export":"Export","kind_buildIndex":"Build Index","column_operationId":"Operation ID","column_status":"Status","column_createdBy":"Created By","column_createTime":"Create Time","column_endTime":"End Time","column_duration":"Duration","label_duration-ongoing":"{{value}} (ongoing)","header_cancel":"Cancel operation","header_forget":"Forget operation","text_cancel":"The operation will be cancelled. Do you want to proceed?","text_forget":"The operation will be forgotten. Do you want to proceed?","text_forgotten":"The operation {{id}} has been forgotten","text_cancelled":"The operation {{id}} has been cancelled"}'),Ge=(0,$e.g4)("ydb-operations",{en:He}),We="id",Ve="status",Je="created_by",Ye="create_time",Ke="end_time",Ze="duration",Xe={[We]:Ge("column_operationId"),[Ve]:Ge("column_status"),[Je]:Ge("column_createdBy"),[Ye]:Ge("column_createTime"),[Ke]:Ge("column_endTime"),[Ze]:Ge("column_duration")},et=[{value:"export",content:Ge("kind_export")},{value:"ss/backgrounds",content:Ge("kind_ssBackgrounds")},{value:"buildindex",content:Ge("kind_buildIndex")}],tt=(0,c.cn)("operations");function at({kind:e,searchValue:t,entitiesCountCurrent:a,entitiesCountTotal:r,entitiesLoading:s,handleKindChange:i,handleSearchChange:o}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Be.v,{value:t,onChange:o,placeholder:Ge("pleaceholder_search"),className:tt("search")}),(0,d.jsx)(le.l,{value:[e],width:150,options:et,onUpdate:e=>i(e[0])}),(0,d.jsx)(Ue.T,{label:Ge("label_operations"),loading:s,total:r,current:a})]})}var nt=a(14750),rt=a(58272),st=a(45345),it=a(98089),ot=a(87184),lt=a(18650),ct=a(99991),dt=a(22983),ut=a(71661);let mt=function(e){return e.STATUS_CODE_UNSPECIFIED="STATUS_CODE_UNSPECIFIED",e.SUCCESS="SUCCESS",e.BAD_REQUEST="BAD_REQUEST",e.UNAUTHORIZED="UNAUTHORIZED",e.INTERNAL_ERROR="INTERNAL_ERROR",e.ABORTED="ABORTED",e.UNAVAILABLE="UNAVAILABLE",e.OVERLOADED="OVERLOADED",e.SCHEME_ERROR="SCHEME_ERROR",e.GENERIC_ERROR="GENERIC_ERROR",e.TIMEOUT="TIMEOUT",e.BAD_SESSION="BAD_SESSION",e.PRECONDITION_FAILED="PRECONDITION_FAILED",e.ALREADY_EXISTS="ALREADY_EXISTS",e.NOT_FOUND="NOT_FOUND",e.SESSION_EXPIRED="SESSION_EXPIRED",e.CANCELLED="CANCELLED",e.UNDETERMINED="UNDETERMINED",e.UNSUPPORTED="UNSUPPORTED",e.SESSION_BUSY="SESSION_BUSY",e.EXTERNAL_ERROR="EXTERNAL_ERROR",e}({});var pt=a(59625);const ht=function({name:e,title:t,type:a,content:n}){return pt.X.add({name:null!==e&&void 0!==e?e:"Request succeeded",title:null!==t&&void 0!==t?t:"Request succeeded",theme:"error"===a?"danger":"success",content:n,isClosable:!0,autoHiding:"success"===a&&5e3})};var vt=a(73891);function gt({database:e,refreshTable:t}){return[{name:We,header:Xe[We],width:340,render:({row:e})=>e.id?(0,d.jsx)(ut.s,{placement:["top","bottom"],content:e.id,children:e.id}):Z.Pd},{name:Ve,header:Xe[Ve],render:({row:e})=>e.status?(0,d.jsx)(it.E,{color:e.status===mt.SUCCESS?"positive":"danger",children:e.status}):Z.Pd},{name:Je,header:Xe[Je],render:({row:e})=>e.created_by?e.created_by:Z.Pd},{name:Ye,header:Xe[Ye],render:({row:e})=>e.create_time?(0,he.r6)((0,vt.ee)(e.create_time)):Z.Pd,sortAccessor:e=>e.create_time?(0,vt.ee)(e.create_time):0},{name:Ke,header:Xe[Ke],render:({row:e})=>e.end_time?(0,he.r6)((0,vt.ee)(e.end_time)):Z.Pd,sortAccessor:e=>e.end_time?(0,vt.ee)(e.end_time):Number.MAX_SAFE_INTEGER},{name:Ze,header:Xe[Ze],render:({row:e})=>{let t=0;if(!e.create_time)return Z.Pd;const a=(0,vt.ee)(e.create_time);if(e.end_time){t=(0,vt.ee)(e.end_time)-a}else t=Date.now()-a;const n=t>Z.Jg*Z.KF?(0,nt.p0)(t).format("hh:mm:ss"):(0,nt.p0)(t).format("mm:ss");return e.end_time?n:Ge("label_duration-ongoing",{value:n})},sortAccessor:e=>{if(!e.create_time)return 0;const t=(0,vt.ee)(e.create_time);if(e.end_time){return(0,vt.ee)(e.end_time)-t}return Date.now()-t}},{name:"Actions",sortable:!1,resizeable:!1,header:"",render:({row:a})=>(0,d.jsx)(yt,{operation:a,database:e,refreshTable:t})}]}function yt({operation:e,database:t,refreshTable:a}){const[n,{isLoading:r}]=Qe.useCancelOperationMutation(),[s,{isLoading:i}]=Qe.useForgetOperationMutation(),o=e.id;return o?(0,d.jsxs)(ot.s,{gap:"2",children:[(0,d.jsx)(lt.m,{title:Ge("header_forget"),placement:["left","auto"],children:(0,d.jsx)("div",{children:(0,d.jsx)(dt.B,{buttonView:"outlined",dialogHeader:Ge("header_forget"),dialogText:Ge("text_forget"),onConfirmAction:()=>s({id:o,database:t}).unwrap().then((()=>{ht({name:"Forgotten",title:Ge("text_forgotten",{id:o}),type:"success"}),a()})),buttonDisabled:r,children:(0,d.jsx)(ct.I,{data:rt.A})})})}),(0,d.jsx)(lt.m,{title:Ge("header_cancel"),placement:["right","auto"],children:(0,d.jsx)("div",{children:(0,d.jsx)(dt.B,{buttonView:"outlined",dialogHeader:Ge("header_cancel"),dialogText:Ge("text_cancel"),onConfirmAction:()=>n({id:o,database:t}).unwrap().then((()=>{ht({name:"Cancelled",title:Ge("text_cancelled",{id:o}),type:"success"}),a()})),buttonDisabled:i,children:(0,d.jsx)(ct.I,{data:st.A})})})})]}):null}var xt=a(370);const bt=xt.z.enum(["ss/backgrounds","export","buildindex"]).catch("buildindex");function ft({database:e}){var t;const[a]=(0,X.Nt)(),{kind:r,searchValue:i,pageSize:o,pageToken:l,handleKindChange:c,handleSearchChange:u}=function(){var e,t,a;const[n,r]=(0,s.useQueryParams)({kind:s.StringParam,search:s.StringParam,pageSize:s.NumberParam,pageToken:s.StringParam});return{kind:bt.parse(n.kind),searchValue:null!==(e=n.search)&&void 0!==e?e:"",pageSize:null!==(t=n.pageSize)&&void 0!==t?t:void 0,pageToken:null!==(a=n.pageToken)&&void 0!==a?a:void 0,handleKindChange:e=>{r({kind:e},"replaceIn")},handleSearchChange:e=>{r({search:e||void 0},"replaceIn")},handlePageSizeChange:e=>{r({pageSize:e},"replaceIn")},handlePageTokenChange:e=>{r({pageToken:e},"replaceIn")}}}(),{data:m,isFetching:p,error:h,refetch:v}=Qe.useGetOperationListQuery({database:e,kind:r,page_size:o,page_token:l},{pollingInterval:a}),g=n.useMemo((()=>null!==m&&void 0!==m&&m.operations?m.operations.filter((e=>{var t;return null===(t=e.id)||void 0===t?void 0:t.toLowerCase().includes(i.toLowerCase())})):[]),[null===m||void 0===m?void 0:m.operations,i]);return(0,ee.Pq)(h)?(0,d.jsx)(ze.O,{position:"left"}):(0,d.jsxs)(qe.L,{children:[(0,d.jsx)(qe.L.Controls,{children:(0,d.jsx)(at,{kind:r,searchValue:i,entitiesCountCurrent:g.length,entitiesCountTotal:null===m||void 0===m||null===(t=m.operations)||void 0===t?void 0:t.length,entitiesLoading:p,handleKindChange:c,handleSearchChange:u})}),h?(0,d.jsx)(de.o,{error:h}):null,(0,d.jsx)(qe.L.Table,{loading:p,className:tt("table"),children:m?(0,d.jsx)(Fe.l,{columns:gt({database:e,refreshTable:v}),columnsWidthLSKey:"selectedOperationColumns",data:g,emptyDataMessage:Ge("title_empty")}):null})]})}var jt=a(99936),St=a(76768),Tt=a(19228),Nt=a(11822);function Et(e){return`SELECT * FROM \`${e}\` LIMIT 0`}const wt=H.F.injectEndpoints({endpoints:e=>({getViewSchema:e.query({queryFn:async({database:e,path:t,timeout:a})=>{try{var n,r;const s=await window.api.viewer.sendQuery({query:Et(t),database:e,action:"execute-scan",timeout:a},{withRetries:!0});return(0,Nt.We)(s)?{error:s}:{data:(null===s||void 0===s||null===(n=s.result)||void 0===n||null===(r=n[0])||void 0===r?void 0:r.columns)||[]}}catch(s){return{error:s}}},providesTags:["All"]})}),overrideExisting:"throw"});var Ct=a(47665),Pt=a(24543);const It=JSON.parse('{"column-title.id":"Id","column-title.name":"Name","column-title.type":"Type","column-title.notNull":"NotNull","column-title.autoIncrement":"AutoIncrement","column-title.defaultValue":"Default","column-title.family":"Family","column-title.media":"Media","column-title.compression":"Compression","primary-key.title":"Primary key:","partitioning-key.title":"Partitioning key:"}'),Dt=(0,$e.g4)("ydb-schema-viewer",{en:It}),At=(0,c.cn)("schema-viewer");const _t=({tableData:e,extended:t,type:a})=>{const n="primary"===a?function(e){return e.filter((e=>void 0!==e.keyColumnIndex&&-1!==e.keyColumnIndex&&e.name)).sort(((e,t)=>e.keyColumnIndex-t.keyColumnIndex)).map((e=>e.name))}(e):function(e){return e.filter((e=>e.isPartitioningKeyColumn&&e.name)).map((e=>e.name))}(e),r=t?3:n.length,s=n.slice(0,r),i=n.slice(r);return n.length>0?(0,d.jsxs)("div",{className:At("keys",{summary:!t,type:a}),children:[(0,d.jsx)("div",{className:At("keys-header"),children:Dt("primary"===a?"primary-key.title":"partitioning-key.title")}),(0,d.jsxs)("div",{className:At("keys-values"),children:[" "+s.join(", "),i.length?(0,d.jsx)(Pt.u,{className:At("more-badge"),placement:["bottom"],hasArrow:!1,pinOnClick:!0,content:(0,d.jsx)("div",{className:At("popup-content"),children:i.map((e=>(0,d.jsx)("div",{className:At("popup-item"),children:e},e)))}),children:(0,d.jsx)(Ct.J,{className:At("keys-label"),children:`+${i.length}`})}):null]})]}):null};var Rt=a(4557);function kt({data:e,name:t,header:a,sortable:n}){const r="string"===typeof a?a.length:t.length;let s=n?r+2:r;if(e)for(const i of e){let e=0;if(i[t]&&(e=String(i[t]).length),s=Math.max(s,e),10*s+20>=600)return 600}return 10*s+20}const Ot="name",Mt="type",Lt="notNull",zt="autoIncrement",Ft="defaultValue",qt="familyName",Qt="prefferedPoolKind",Ut="columnCodec",Bt={name:"id",get header(){return Dt("column-title.id")},width:60,render:({row:e})=>e.id},$t={name:Ot,get header(){return Dt("column-title.name")},width:120,render:({row:e})=>e.name},Ht={name:Mt,get header(){return Dt("column-title.type")},width:100,render:({row:e})=>e.type},Gt={name:Lt,get header(){return Dt("column-title.notNull")},width:100,defaultOrder:Rt.Ay.DESCENDING,render:({row:e})=>{if(e.notNull)return"\u2713"}},Wt={name:zt,get header(){return Dt("column-title.autoIncrement")},width:100,defaultOrder:Rt.Ay.DESCENDING,render:({row:e})=>{if(e.autoIncrement)return"\u2713"}},Vt={name:Ft,get header(){return Dt("column-title.defaultValue")},width:100,render:({row:e})=>String(e.defaultValue)},Jt={name:qt,get header(){return Dt("column-title.family")},width:100,render:({row:e})=>e.familyName},Yt={name:Qt,get header(){return Dt("column-title.media")},width:100,render:({row:e})=>e.prefferedPoolKind},Kt={name:Ut,get header(){return Dt("column-title.compression")},width:130,render:({row:e})=>e.columnCodec};function Zt(e,t){if(!t)return e;const a=t.slice(0,100);return e.map((e=>({...e,width:kt({data:a,name:e.name,header:"string"===typeof e.header?e.header:void 0,sortable:e.sortable||void 0===e.sortable})})))}function Xt(e={}){const t=function(e){var t,a,n;return null!==(t=null===e||void 0===e||null===(a=e.PartitionConfig)||void 0===a||null===(n=a.ColumnFamilies)||void 0===n?void 0:n.reduce(((e,t)=>t.Id?{...e,[t.Id]:t}:e),{}))&&void 0!==t?t:{}}(e),{Columns:a,KeyColumnNames:n}=e,r=null===a||void 0===a?void 0:a.map((e=>{var a,r,s,i;const{Id:o,Name:l,NotNull:c,Type:d,Family:u,DefaultFromSequence:m,DefaultFromLiteral:p}=e,h=null!==(a=null===n||void 0===n?void 0:n.findIndex((e=>e===l)))&&void 0!==a?a:-1,v=u?t[u].Name:void 0,g=u?null===(r=t[u].StorageConfig)||void 0===r||null===(s=r.Data)||void 0===s?void 0:s.PreferredPoolKind:void 0,y=u?function(e){if(e)return e===f.ColumnCodecPlain?"None":e.replace("ColumnCodec","").toLocaleLowerCase()}(t[u].ColumnCodec):void 0;return{id:o,name:l,keyColumnIndex:h,type:d,notNull:c,autoIncrement:Boolean(m),defaultValue:null!==(i=Object.values((null===p||void 0===p?void 0:p.value)||{})[0])&&void 0!==i?i:"-",familyName:v,prefferedPoolKind:g,columnCodec:y}}));return[...(null===r||void 0===r?void 0:r.filter((e=>-1!==e.keyColumnIndex)))||[],...(null===r||void 0===r?void 0:r.filter((e=>-1===e.keyColumnIndex)))||[]]}function ea(e,t){const{Table:a,ColumnTableDescription:n,ExternalTableDescription:r}=(null===t||void 0===t?void 0:t.PathDescription)||{};return B(e)?Xt(a):k(e)?function(e={}){const{Schema:t={},Sharding:a={}}=e,{Columns:n,KeyColumnNames:r}=t,{HashSharding:s={}}=a,{Columns:i=[]}=s,o=null===n||void 0===n?void 0:n.map((e=>{var t;const{Id:a,Name:n,Type:s,NotNull:o}=e,l=null!==(t=null===r||void 0===r?void 0:r.findIndex((e=>e===n)))&&void 0!==t?t:-1,c=Boolean(null===i||void 0===i?void 0:i.find((e=>e===n)));return{id:a,name:n,keyColumnIndex:l,isPartitioningKeyColumn:c,type:s,notNull:o}}));return[...(null===o||void 0===o?void 0:o.filter((e=>-1!==e.keyColumnIndex)))||[],...(null===o||void 0===o?void 0:o.filter((e=>-1===e.keyColumnIndex)))||[]]}(n):U(e)?function(e={}){const{Columns:t}=e;return(null===t||void 0===t?void 0:t.map((e=>{const{Id:t,Name:a,Type:n,NotNull:r}=e;return{id:t,name:a,type:n,notNull:r}})))||[]}(r):[]}function ta(e){return(null===e||void 0===e?void 0:e.map((e=>{var t;return{type:null!==(t=e.type)&&void 0!==t&&t.endsWith("?")?e.type.slice(0,-1):e.type,name:e.name}})))||[]}const aa=({type:e,path:t,tenantName:a,extended:r=!1})=>{const[s]=(0,X.Nt)(),{currentData:i,isLoading:o}=G.useGetOverviewQuery({path:t,database:a},{pollingInterval:s}),l=$(e)?{path:t,database:a}:y.hT,{data:c,isLoading:u}=wt.useGetViewSchemaQuery(l),m=n.useMemo((()=>$(e)?ta(c):ea(e,i)),[i,e,c]),p=n.useMemo((()=>m.some((e=>e.autoIncrement))),[m]),h=n.useMemo((()=>m.some((e=>e.defaultValue))),[m]),v=n.useMemo((()=>$(e)?Zt([$t,Ht],m):U(e)||k(e)?function(e){return Zt([Bt,$t,Ht,Gt],e)}(m):B(e)?function(e,t,a,n){const r=[Bt,$t,Ht,Gt];return n&&r.push(Vt),t&&r.push(Jt,Yt,Kt),a&&r.push(Wt),Zt(r,e)}(m,r,p,h):[]),[e,r,p,h,m]);return o||u?(0,d.jsx)(Tt.Q,{}):(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)("div",{className:At("keys-wrapper"),children:[(0,d.jsx)(_t,{tableData:m,extended:r,type:"primary"}),(0,d.jsx)(_t,{tableData:m,extended:r,type:"partitioning"})]}),(0,d.jsx)("div",{className:At(),children:(0,d.jsx)(Fe.l,{columnsWidthLSKey:"schemaTableColumnsWidth",data:m,columns:v,settings:Z.N3})})]})};var na=a(54309),ra=a(96589),sa=a(84375),ia=a(85589);const oa=JSON.parse('{"td-feature-flag":"Feature flag","td-default":"Default","td-current":"Current","enabled":"Enabled","disabled":"Disabled","flag-touched":"Flag is changed","search-placeholder":"Search by feature flag","search-empty":"Empty search result","no-data":"No data"}'),la=(0,$e.g4)("ydb-diagnostics-configs",{en:oa}),ca=(0,c.cn)("ydb-diagnostics-configs"),da=[{name:"Touched",header:"",render:({row:e})=>e.Current?(0,d.jsx)(sa.A,{content:la("flag-touched"),className:ca("icon-touched"),placement:"left",children:(0,d.jsx)(ct.I,{data:ra.A})}):null,width:36,sortable:!1,resizeable:!1},{name:"Name",get header(){return la("td-feature-flag")},render:({row:e})=>e.Current?(0,d.jsx)("b",{children:e.Name}):e.Name,width:400,sortable:!0,sortAccessor:({Current:e,Name:t})=>Number(!e)+t.toLowerCase()},{name:"Default",get header(){return la("td-default")},render:({row:e})=>{switch(e.Default){case!0:return la("enabled");case!1:return la("disabled");default:return"-"}},width:100,sortable:!1,resizeable:!1},{name:"Current",get header(){return la("td-current")},render:({row:e})=>{var t;return(0,d.jsx)(ia.d,{disabled:!0,checked:(null!==(t=e.Current)&&void 0!==t?t:e.Default)||!1})},width:100,sortable:!1,resizeable:!1}],ua=({database:e})=>{const[t,a]=(0,s.useQueryParam)("search",s.StringParam),[n]=(0,X.Nt)(),{currentData:r=[],isFetching:i,error:o}=oe.z6.useGetClusterConfigQuery({database:e},{pollingInterval:n}),l=null===t||void 0===t?void 0:t.toLocaleLowerCase(),c=l?r.filter((e=>e.Name.toLocaleLowerCase().includes(l))):r;return(0,d.jsxs)(qe.L,{children:[(0,d.jsx)(qe.L.Controls,{children:(0,d.jsx)(Be.v,{value:l,onChange:e=>{a(e||void 0,"replaceIn")},placeholder:la("search-placeholder")})}),(0,d.jsx)(qe.L.Table,{loading:i,children:o?(0,d.jsx)(de.o,{error:o}):(0,d.jsx)(Fe.l,{emptyDataMessage:la(l?"search-empty":"no-data"),columnsWidthLSKey:"featureFlagsColumnsWidth",columns:da,data:c,settings:Z.N3})})]})};var ma=a(23536),pa=a.n(ma),ha=a(46549);const va=H.F.injectEndpoints({endpoints:e=>({getTopic:e.query({queryFn:async e=>{try{const t=await window.api.viewer.getTopic(e);return"object"!==typeof t?{error:{}}:{data:t}}catch(t){return{error:t}}},providesTags:["All"]})}),overrideExisting:"throw"}),ga=(0,g.Mz)((e=>e),((e,t)=>t),((e,t)=>va.endpoints.getTopic.select({path:e,database:t}))),ya=(0,g.Mz)((e=>e),((e,t,a)=>ga(t,a)),((e,t)=>{var a;return null===(a=t(e).data)||void 0===a?void 0:a.topic_stats})),xa=(0,g.Mz)((e=>e),((e,t,a)=>ga(t,a)),((e,t)=>{var a;return null===(a=t(e).data)||void 0===a?void 0:a.consumers})),ba=(0,g.Mz)(xa,(e=>null===e||void 0===e?void 0:e.map((e=>null===e||void 0===e?void 0:e.name)).filter((e=>void 0!==e)))),fa=(0,g.Mz)(ya,(e=>{if(!e)return;const{store_size_bytes:t="0",min_last_write_time:a,max_write_time_lag:n,bytes_written:r}=e||{};return{storeSize:t,partitionsIdleTime:(0,vt.MC)(a),partitionsWriteLag:(0,vt.i6)(n),writeSpeed:(0,ha.ey)(r)}})),ja=(0,g.Mz)(xa,(e=>null===e||void 0===e?void 0:e.map((e=>{const{name:t,consumer_stats:a}=e||{},{min_partitions_last_read_time:n,max_read_time_lag:r,max_write_time_lag:s,bytes_read:i}=a||{};return{name:t,readSpeed:(0,ha.ey)(i),writeLag:(0,vt.i6)(s),readLag:(0,vt.i6)(r),readIdleTime:(0,vt.MC)(n)}})))),Sa=JSON.parse('{"averageSpeed":"Average speed","perMinute":"per minute","perHour":"per hour","perDay":"per day"}'),Ta=JSON.parse('{"averageSpeed":"\u0421\u0440\u0435\u0434\u043d\u044f\u044f \u0441\u043a\u043e\u0440\u043e\u0441\u0442\u044c","perMinute":"\u0437\u0430 \u043c\u0438\u043d\u0443\u0442\u0443","perHour":"\u0437\u0430 \u0447\u0430\u0441","perDay":"\u0437\u0430 \u0434\u0435\u043d\u044c"}'),Na=(0,$e.g4)("ydb-components-speed-multimeter",{ru:Ta,en:Sa}),Ea=(0,c.cn)("speed-multimeter"),wa=({data:e,speedSize:t="kb",withValue:a=!0,withPopover:r=!0})=>{const{perMinute:s=0,perHour:i=0,perDay:o=0}=e||{},l=[s,i,o],c=e=>(0,ha.z3)({value:e,size:t,withSpeedLabel:!0}),u=[{value:c(s),label:Na("perMinute")},{value:c(i),label:Na("perHour")},{value:c(o),label:Na("perDay")}],[m,p]=n.useState(s),[h,v]=n.useState(a?0:void 0),[g,y]=n.useState(),x=(e,t)=>{p(e[t]),v(t),y(t)},b=e=>h===e,f=e=>g===e;return(0,d.jsx)("div",{className:Ea(),children:(0,d.jsxs)("div",{className:Ea("content"),children:[a&&(0,d.jsx)("div",{className:Ea("displayed-value"),children:c(m)}),(0,d.jsx)(sa.A,{content:(0,d.jsxs)("div",{className:Ea("popover-content"),children:[(0,d.jsx)("span",{className:Ea("popover-header"),children:Na("averageSpeed")}),u.map(((e,t)=>{return(0,d.jsx)("span",{className:Ea("popover-row",(a=b(t),a?{color:"primary"}:{color:"secondary"})),children:`${e.label}: ${e.value}`},t);var a}))]}),className:Ea("popover-container"),placement:"bottom",disabled:!r,hasArrow:!0,size:"s",children:(0,d.jsx)("div",{className:Ea("bars"),onMouseLeave:()=>{p(s),v(a?0:void 0),y(void 0)},children:(()=>{const e=Math.max(...l,0)||1;return l.map(((t,a)=>(0,d.jsx)("div",{className:Ea("bar-container",{highlighted:f(a)}),onMouseEnter:x.bind(null,l,a),children:(0,d.jsx)("div",{className:Ea("bar",{color:b(a)?"dark":"light"}),style:{width:100*t/e+"%"}})},a)))})()})})]})})},Ca=(0,c.cn)("ydb-diagnostics-consumers-topic-stats"),Pa=({data:e})=>{const{writeSpeed:t,partitionsWriteLag:a,partitionsIdleTime:n}=e||{},r=[{label:"Write speed",value:(0,d.jsx)(wa,{data:t})},{label:"Write lag",value:(0,he.lr)(a||0)},{label:"Write idle time",value:(0,he.lr)(n||0)}];return(0,d.jsx)("div",{className:Ca("wrapper"),children:r.map(((e,t)=>(0,d.jsxs)("div",{className:Ca("item"),children:[(0,d.jsx)("div",{className:Ca("label"),children:e.label}),(0,d.jsx)("div",{className:Ca("value"),children:e.value})]},t)))})};var Ia=a(74309),Da=a.n(Ia),Aa=a(44294),_a=a(6170);const Ra=({text:e,popoverContent:t,popoverClassName:a,className:n,contentClassName:r,buttonProps:s})=>(0,d.jsxs)("div",{className:n,children:[e,"\xa0",(0,d.jsx)(_a.B,{className:a,buttonProps:s,content:t,contentClassName:r})]}),ka=70,Oa=54,Ma=268,La="#ADE8F5",za="#f5be9d",Fa=({width:e,height:t,transform:a})=>(0,d.jsx)("path",{d:`M-${e/2} 0 c0 -${t}, ${e} -${t}, ${e} 0`,fill:"none",strokeDasharray:"4,6",stroke:"#28f",strokeWidth:"1.6",transform:a}),qa=({width:e})=>(0,d.jsx)("path",{fill:"none",strokeWidth:"2",d:`M0 0 h${e} l-10 -5 m0 10 l10 -5`}),Qa=()=>(0,d.jsxs)("g",{fill:"var(--g-color-text-primary)",fontSize:"12",children:[(0,d.jsx)("g",{transform:"translate(0, 27)",stroke:za,children:(0,d.jsx)(qa,{width:203})}),(0,d.jsxs)("g",{transform:"translate(30, 0)",children:[(0,d.jsxs)("g",{transform:"translate(35, 27)",children:[(0,d.jsx)(Fa,{width:ka,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write lag"})})]}),(0,d.jsxs)("g",{transform:"translate(119, 27)",children:[(0,d.jsx)(Fa,{width:98,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write idle time"})})]})]}),(0,d.jsxs)("g",{transform:"translate(30, 0)",children:[(0,d.jsxs)("g",{transform:"translate(0, 27)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:za}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"create time"})})]}),(0,d.jsxs)("g",{transform:"translate(70, 27)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:za}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write time"})})]}),(0,d.jsx)("g",{transform:"translate(168, 27)",children:(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"now"})})})]})]}),Ua=()=>(0,d.jsxs)("g",{fill:"var(--g-color-text-primary)",fontSize:"12",children:[(0,d.jsx)("g",{transform:"translate(0, 27)",stroke:La,children:(0,d.jsx)(qa,{width:Ma})}),(0,d.jsxs)("g",{transform:"translate(30, 0)",children:[(0,d.jsxs)("g",{transform:"translate(105, 27)",children:[(0,d.jsx)(Fa,{width:ka,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"read lag"})})]}),(0,d.jsxs)("g",{transform:"translate(35, 27)",children:[(0,d.jsx)(Fa,{width:ka,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write lag"})})]}),(0,d.jsxs)("g",{transform:"translate(182, 27)",children:[(0,d.jsx)(Fa,{width:91,height:15}),(0,d.jsx)("text",{x:"0",y:"-15",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"read idle time"})})]})]}),(0,d.jsxs)("g",{transform:"translate(30, 27)",children:[(0,d.jsxs)("g",{transform:"translate(0, 0)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:La}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"create time"})})]}),(0,d.jsxs)("g",{transform:"translate(70, 0)",children:[(0,d.jsx)("use",{y:"-10",xlinkHref:"#check",stroke:La}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"write time"})})]}),(0,d.jsxs)("g",{transform:"translate(140, 0)",children:[(0,d.jsx)("use",{x:"-2",y:"-10",xlinkHref:"#check",stroke:La}),(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"read time"})})]}),(0,d.jsx)("g",{transform:"translate(224, 0)",children:(0,d.jsx)("text",{x:"0",y:"20",textAnchor:"middle",children:(0,d.jsx)("tspan",{x:"0",dy:"0",children:"now"})})})]})]}),Ba=({id:e,fill:t})=>(0,d.jsx)("pattern",{id:e,x:"0",y:"0",width:"8",height:"8",patternUnits:"userSpaceOnUse",children:(0,d.jsx)("path",{d:"M0 5L5 0H8L0 8V5M5 8L8 5V8Z",fill:t})}),$a=()=>(0,d.jsxs)("svg",{className:"paint",xmlns:"http://www.w3.org/2000/svg",xmlnsXlink:"http://www.w3.org/1999/xlink",viewBox:"0 0 268 54",width:Ma,height:Oa,children:[(0,d.jsxs)("defs",{children:[(0,d.jsx)("g",{id:"check",children:(0,d.jsx)("path",{d:"M0 3 v14",strokeWidth:"2"})}),(0,d.jsx)(Ba,{id:"latest-read",fill:La}),(0,d.jsx)(Ba,{id:"latest-write",fill:za})]}),(0,d.jsx)(Qa,{})]}),Ha=()=>(0,d.jsxs)("svg",{className:"paint",xmlns:"http://www.w3.org/2000/svg",xmlnsXlink:"http://www.w3.org/1999/xlink",viewBox:"0 0 268 54",width:Ma,height:Oa,children:[(0,d.jsxs)("defs",{children:[(0,d.jsx)("g",{id:"check",children:(0,d.jsx)("path",{d:"M0 3 v14",strokeWidth:"2"})}),(0,d.jsx)(Ba,{id:"latest-read",fill:La}),(0,d.jsx)(Ba,{id:"latest-write",fill:za})]}),(0,d.jsx)(Ua,{})]}),Ga=(0,c.cn)("ydb-lag-popover-content"),Wa=({text:e,type:t})=>(0,d.jsxs)("div",{className:Ga({type:t}),children:[(0,d.jsx)("div",{className:Ga("text"),children:e}),(0,d.jsx)("div",{children:"read"===t?(0,d.jsx)(Ha,{}):(0,d.jsx)($a,{})})]}),Va=JSON.parse('{"noConsumersMessage.topic":"This topic has no consumers","noConsumersMessage.stream":"This changefeed has no consumers","lagsPopover.readLags":"Read lags statistics, maximum among all consumer partitions (time format dd hh:mm:ss)","table.emptyDataMessage":"No consumers match the current search","controls.search":"Consumer"}'),Ja=JSON.parse('{"noConsumersMessage.topic":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0442\u043e\u043f\u0438\u043a\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","noConsumersMessage.stream":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0441\u0442\u0440\u0438\u043c\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","lagsPopover.readLags":"\u0421\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0430 \u043b\u0430\u0433\u043e\u0432 \u0447\u0442\u0435\u043d\u0438\u044f, \u043c\u0430\u043a\u0441\u0438\u043c\u0430\u043b\u044c\u043d\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0441\u0440\u0435\u0434\u0438 \u0432\u0441\u0435\u0445 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u044f (\u0444\u043e\u0440\u043c\u0430\u0442 \u0432\u0440\u0435\u043c\u0435\u043d\u0438 \u0434\u0434 \u0447\u0447:\u043c\u043c:\u0441\u0441)","table.emptyDataMessage":"\u041f\u043e \u0437\u0430\u0434\u0430\u043d\u043d\u043e\u043c\u0443 \u043f\u043e\u0438\u0441\u043a\u0443 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","controls.search":"Consumer"}'),Ya=(0,$e.g4)("ydb-diagnostics-consumers",{ru:Ja,en:Va}),Ka="consumer",Za="readSpeed",Xa="readLags",en={[Ka]:"Consumer",[Za]:"Read speed",[Xa]:"Read lags, duration"},tn="writeLag",an="readLag",nn="readIdleTime",rn={[tn]:"write lag",[an]:"read lag",[nn]:"read idle time"},sn=(0,c.cn)("ydb-diagnostics-consumers-columns-header"),on=()=>(0,d.jsx)(Ra,{className:sn("lags"),text:en[Xa],popoverContent:(0,d.jsx)(Wa,{text:Ya("lagsPopover.readLags"),type:"read"})}),ln=(0,c.cn)("ydb-diagnostics-consumers-columns"),cn=[{name:Ka,header:en[Ka],align:Rt.Ay.LEFT,render:({row:e})=>{if(!e.name)return"\u2013";const t=Da().parse(location.search,{ignoreQueryPrefix:!0});return(0,d.jsx)(Aa.E,{to:(0,na.YL)({...t,[na.vh.diagnosticsTab]:ae.iJ.partitions,selectedConsumer:e.name}),children:e.name})}},{name:Za,header:en[Za],align:Rt.Ay.RIGHT,resizeMinWidth:140,sortAccessor:e=>e.readSpeed.perMinute,render:({row:e})=>(0,d.jsx)(wa,{data:e.readSpeed})},{name:Xa,header:(0,d.jsx)(on,{}),className:ln("lags-header"),sub:[{name:tn,header:rn[tn],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.writeLag)},{name:an,header:rn[an],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.readLag)},{name:nn,header:rn[nn],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.readIdleTime)}]}],dn=(0,c.cn)("ydb-diagnostics-consumers"),un=({path:e,database:t,type:a})=>{const r=(e=>e===x.EPathTypeCdcStream)(a),[s,i]=n.useState(""),[o]=(0,X.Nt)(),{currentData:l,isFetching:c,error:u}=va.useGetTopicQuery({path:e,database:t},{pollingInterval:o}),m=c&&void 0===l,p=(0,X.N4)((a=>ja(a,e,t))),h=(0,X.N4)((a=>fa(a,e,t))),v=n.useMemo((()=>{if(!p)return[];const e=new RegExp(pa()(s),"i");return p.filter((t=>e.test(String(t.name))))}),[p,s]);return m?(0,d.jsx)(ue.a,{size:"m"}):u||p&&p.length?(0,d.jsxs)("div",{className:dn(),children:[(0,d.jsxs)("div",{className:dn("controls"),children:[(0,d.jsx)(Be.v,{onChange:e=>{i(e)},placeholder:Ya("controls.search"),className:dn("search"),value:s}),h&&(0,d.jsx)(Pa,{data:h})]}),u?(0,d.jsx)(de.o,{error:u}):null,p?(0,d.jsx)("div",{className:dn("table-wrapper"),children:(0,d.jsx)("div",{className:dn("table-content"),children:(0,d.jsx)(Fe.l,{columnsWidthLSKey:"consumersColumnsWidth",wrapperClassName:dn("table"),data:v,columns:cn,settings:Z.N3,emptyDataMessage:Ya("table.emptyDataMessage")})})}):null]}):(0,d.jsx)("div",{children:Ya("noConsumersMessage."+(r?"stream":"topic"))})};var mn=a(96873),pn=a(97434),hn=a(84476),vn=a(67063),gn=a.n(vn);const yn=JSON.parse('{"context_case-sensitive-search":"Case sensitive search enadled","context_case-sensitive-search-disabled":"Case sensitive search disabled"}'),xn=(0,$e.g4)("ydb-json-tree",{en:yn});var bn=a(94630);a(91434);const fn=(0,c.cn)("ydb-json-tree");function jn({treeClassName:e,search:t,...a}){const[n,r]=(0,X.iK)(Z.iD,!1);return(0,d.jsxs)("div",{className:fn(),children:[(0,d.jsx)(gn(),{className:fn("tree",e),filterOptions:{ignoreCase:!n},searchOptions:{debounceTime:300},...a}),!1!==t&&(0,d.jsx)(lt.m,{title:xn(n?"context_case-sensitive-search":"context_case-sensitive-search-disabled"),children:(0,d.jsx)(hn.$,{view:"outlined",className:fn("case"),onClick:()=>r(!n),selected:n,children:(0,d.jsx)(ct.I,{data:bn.A})})})]})}const Sn=(0,c.cn)("ydb-describe"),Tn=new Map,Nn=({path:e,database:t,type:a})=>{const[n]=(0,X.Nt)(),r=z(a),s=(0,X.N4)((n=>J(n,e,a,t)),pn.bN);let i=[];r?s&&(i=[e,...s]):i=[e];const{mergedDescribe:o,loading:l,error:c}=Y({paths:i,autoRefreshInterval:n,database:t});let u;if(o){const e=Object.keys(o);u=1===e.length?o[e[0]]:o}return l||r&&!s?(0,d.jsx)(ue.a,{size:"m"}):u||c?(0,d.jsxs)("div",{className:Sn(),children:[c?(0,d.jsx)(de.o,{error:c}):null,u?(0,d.jsxs)("div",{className:Sn("result"),children:[(0,d.jsx)(jn,{data:u,onClick:({path:e})=>{const t=!Tn.get(e);Tn.set(e,t)},isExpanded:e=>Tn.get(e)||!1}),(0,d.jsx)(mn.b,{view:"flat-secondary",text:JSON.stringify(u),className:Sn("copy")})]}):null]}):(0,d.jsx)("div",{className:Sn("message-container"),children:"Empty"})};var En=a(60073);const wn=e=>{const{PathType:t,PathSubType:a}=(null===e||void 0===e?void 0:e.Self)||{};return n=t,(r=a)&&w[r]||n&&C[n];var n,r},Cn=e=>{var t;return null===e||void 0===e||null===(t=e.UserAttributes)||void 0===t?void 0:t.some((({Key:e,Value:t})=>"__async_replica"===e&&"true"===t))};var Pn=a(5741),In=a(82176);const Dn=(0,In.H)({values:{PathType:e=>null===e||void 0===e?void 0:e.substring(9),CreateStep:he.r6},labels:{PathType:(0,Pn.A)("common.type"),CreateStep:(0,Pn.A)("common.created")}}),An=({value:e,withSpeedLabel:t,...a})=>{const n=(0,ha.z3)({value:e,withSpeedLabel:t,...a}),r=(0,ha.z3)({value:e,withSpeedLabel:t,size:"b"});return(0,d.jsx)("span",{title:r,children:n})},_n=(e,t)=>e?(0,d.jsx)(An,{value:e,significantDigits:2,...t}):null,Rn=(0,In.H)({values:{Type:e=>null===e||void 0===e?void 0:e.substring(10),State:e=>null===e||void 0===e?void 0:e.substring(11),KeyColumnNames:e=>null===e||void 0===e?void 0:e.join(", "),DataColumnNames:e=>null===e||void 0===e?void 0:e.join(", "),DataSize:_n},labels:{KeyColumnNames:"Columns",DataColumnNames:"Includes"}}),kn={[j.METERING_MODE_REQUEST_UNITS]:"request-units",[j.METERING_MODE_RESERVED_CAPACITY]:"reserved-capacity"},On=(0,In.H)({values:{Partitions:e=>(0,he.ZV)((null===e||void 0===e?void 0:e.length)||0),PQTabletConfig:e=>{const t=Math.round(e.PartitionConfig.LifetimeSeconds/Z.Jg*100)/100;return`${(0,he.ZV)(t)} hours`}},labels:{Partitions:"Partitions count",PQTabletConfig:"Retention"}}),Mn=(0,In.H)({values:{Codecs:e=>e&&Object.values(e.Codecs||{}).join(", "),MeteringMode:e=>e&&kn[e]},labels:{MeteringMode:"Metering mode"}}),Ln=(0,In.H)({values:{StorageLimitBytes:he.z3,WriteSpeedInBytesPerSecond:he.tC},labels:{StorageLimitBytes:"Retention storage",WriteSpeedInBytesPerSecond:"Partitions write speed"}}),zn=(0,In.H)({values:{Mode:e=>null===e||void 0===e?void 0:e.substring(14),Format:e=>null===e||void 0===e?void 0:e.substring(16)}}),Fn=(0,In.H)({values:{CPU:he.iM,Memory:_n,Storage:_n,Network:he.tC,ReadThroughput:he.tC,WriteThroughput:he.tC},defaultValueFormatter:he.ZV}),qn=(0,In.H)({values:{FollowerCount:he.ZV},labels:{FollowerCountPerDataCenter:"FollowerCountPerDC"},defaultValueFormatter:e=>e&&String(e)}),Qn=(0,In.H)({values:{FollowerCount:he.ZV,CrossDataCenterFollowerCount:he.ZV}}),Un=(0,In.H)({values:{DataSize:_n,IndexSize:_n,LastAccessTime:he.r6,LastUpdateTime:he.r6},defaultValueFormatter:he.ZV}),Bn=new Set(["Type","State","DataSize","KeyColumnNames","DataColumnNames"]),$n=({data:e})=>{var t;const a=wn(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:["No ",a," data"]});const n=null===(t=e.PathDescription)||void 0===t?void 0:t.TableIndex,r=[];let s;for(s in n)Bn.has(s)&&r.push(Rn(s,null===n||void 0===n?void 0:n[s]));return(0,d.jsx)(En.z_,{title:a,info:r})};var Hn=a(10508);const Gn=JSON.parse('{"external-objects.source-type":"Source Type","external-objects.data-source":"Data Source","external-objects.location":"Location","external-objects.auth-method":"Auth Method","external-objects.auth-method.none":"None","external-objects.auth-method.service-account":"Service Account","view.query-text":"Query Text"}'),Wn=(0,$e.g4)("ydb-tenant-objects-info",{en:Gn}),Vn=(0,c.cn)("ydb-external-data-source-info"),Jn=e=>{var t,a,n,r;return[{label:Wn("external-objects.source-type"),value:null===(t=e.PathDescription)||void 0===t||null===(a=t.ExternalDataSourceDescription)||void 0===a?void 0:a.SourceType},Dn("CreateStep",null===(n=e.PathDescription)||void 0===n||null===(r=n.Self)||void 0===r?void 0:r.CreateStep)]},Yn=e=>{var t;const{Location:a,Auth:n}=(null===(t=e.PathDescription)||void 0===t?void 0:t.ExternalDataSourceDescription)||{};return[...Jn(e),{label:Wn("external-objects.location"),value:(0,d.jsx)(Hn.c,{name:a,showStatus:!1,hasClipboardButton:!0,clipboardButtonAlwaysVisible:!0,className:Vn("location")})},{label:Wn("external-objects.auth-method"),value:null!==n&&void 0!==n&&n.ServiceAccount?Wn("external-objects.auth-method.service-account"):Wn("external-objects.auth-method.none")}]},Kn=({data:e,prepareData:t})=>{const a=wn(null===e||void 0===e?void 0:e.PathDescription);return e?(0,d.jsx)(En.z_,{title:a,info:t(e)}):(0,d.jsxs)("div",{className:"error",children:["No ",a," data"]})},Zn=({data:e})=>(0,d.jsx)(Kn,{data:e,prepareData:Yn});var Xn=a(10755),er=a(25196);const tr=(0,c.cn)("ydb-external-table-info"),ar=(e,t)=>{var a,n;const{CreateStep:r}=(null===(a=e.PathDescription)||void 0===a?void 0:a.Self)||{},{SourceType:s,DataSourcePath:i}=(null===(n=e.PathDescription)||void 0===n?void 0:n.ExternalTableDescription)||{},o=null===i||void 0===i?void 0:i.split("/").pop();return[{label:Wn("external-objects.source-type"),value:s},Dn("CreateStep",r),{label:Wn("external-objects.data-source"),value:i&&(0,d.jsx)("span",{title:i,children:(0,d.jsx)(er.K,{title:o||"",url:t})})}]},nr=(e,t)=>{var a,n;const r=null===(a=e.PathDescription)||void 0===a||null===(n=a.ExternalTableDescription)||void 0===n?void 0:n.Location;return[...ar(e,t),{label:Wn("external-objects.location"),value:(0,d.jsx)(Hn.c,{name:r,showStatus:!1,hasClipboardButton:!0,clipboardButtonAlwaysVisible:!0,className:tr("location")})}]},rr=({data:e,prepareData:t})=>{var a,n;const r=(0,Xn.zy)(),s=(0,ye.mA)(r),i=(0,ye.Ow)({...s,schema:null===e||void 0===e||null===(a=e.PathDescription)||void 0===a||null===(n=a.ExternalTableDescription)||void 0===n?void 0:n.DataSourcePath}),o=wn(null===e||void 0===e?void 0:e.PathDescription);return e?(0,d.jsx)(En.z_,{title:o,info:t(e,i)}):(0,d.jsxs)("div",{className:"error",children:["No ",o," data"]})},sr=({data:e})=>(0,d.jsx)(rr,{data:e,prepareData:nr});var ir=a(57439);const or=JSON.parse('{"no-data":"No data"}'),lr=(0,$e.g4)("ydb-definition-list",{en:or}),cr=(0,c.cn)("ydb-definition-list");function dr({title:e,items:t,nameMaxWidth:a=220,copyPosition:n="outside",className:r,itemClassName:s,...i}){return(0,d.jsxs)("div",{className:cr(null),children:[e?(0,d.jsx)("div",{className:cr("title"),children:e}):null,t.length?(0,d.jsx)(ir.u,{items:t,nameMaxWidth:a,copyPosition:n,className:cr("properties-list",r),itemClassName:cr("item",s),...i}):lr("no-data")]})}var ur=a(96298),mr=a(8300);ur.A.registerLanguage("yql",mr.TL);const pr=(0,c.cn)("yql-highlighter"),hr=({children:e,className:t})=>{const a=(0,te.i)(),n="dark"===a||"dark-hc"===a;return(0,d.jsx)("div",{className:pr(null,t),children:(0,d.jsx)(ur.A,{language:"yql",style:n?mr.XT:mr.BB,children:e})})};function vr({data:e}){const t=wn(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:["No ",t," data"]});const a=(e=>{var t,a;const n=null===(t=e.PathDescription)||void 0===t||null===(a=t.ViewDescription)||void 0===a?void 0:a.QueryText;return[{name:Wn("view.query-text"),copyText:n,content:n?(0,d.jsx)(hr,{children:n}):null}]})(e);return(0,d.jsx)(dr,{title:t,items:a})}function gr({state:e}){return e?"StandBy"in e?(0,d.jsx)(Ct.J,{theme:"info",children:"Standby"}):"Paused"in e?(0,d.jsx)(Ct.J,{theme:"info",children:"Paused"}):"Done"in e?(0,d.jsx)(Ct.J,{theme:"success",children:"Done"}):"Error"in e?(0,d.jsx)(Ct.J,{theme:"danger",children:"Error"}):(0,d.jsx)(Ct.J,{size:"s",children:"Unknown"}):null}const yr=JSON.parse('{"column.dstPath.name":"Dist","column.srcPath.name":"Source","everythingWithPrefix":"Everything with prefix:","noData":"No data.","title":"Replicated Paths"}'),xr=(0,$e.g4)("ydb-diagnostics-async-replication-paths",{en:yr}),br=(0,c.cn)("ydb-async-replication-paths"),fr=[{name:xr("column.srcPath.name"),render:({row:e})=>e.SrcPath,sortAccessor:e=>e.SrcPath},{name:xr("column.dstPath.name"),render:({row:e})=>e.DstPath,sortAccessor:e=>e.DstPath}];function jr({config:e}){if(!e)return null;let t=xr("noData");var a,n;e.Everything&&(t=(0,d.jsxs)("span",{children:[xr("everythingWithPrefix")," ",(0,d.jsx)(it.E,{variant:"code-inline-2",children:null!==(a=null===(n=e.Everything)||void 0===n?void 0:n.DstPrefix)&&void 0!==a?a:"undefined"}),"."]}));return e.Specific&&(t=(0,d.jsx)(Fe.l,{data:e.Specific.Targets,settings:Z.jp,columns:fr})),(0,d.jsxs)("div",{className:br(),children:[(0,d.jsx)("div",{className:br("title"),children:xr("title")}),t]})}function Sr({connection:e}){return e?e.StaticCredentials?(0,d.jsx)(Ct.J,{value:e.StaticCredentials.User,theme:"normal",children:"user"}):"OAuthToken"in e?"OAuth":"unknown":null}const Tr=JSON.parse('{"credentials.label":"Credentials","noData":"No data for entity:","srcConnection.database.label":"Source Database Path","srcConnection.endpoint.label":"Source Cluster Endpoint","state.label":"State"}'),Nr=(0,$e.g4)("ydb-diagnostics-async-replication-info",{en:Tr});function Er({data:e}){var t,a;const n=wn(null===e||void 0===e?void 0:e.PathDescription);if(!e)return(0,d.jsxs)("div",{className:"error",children:[Nr("noData")," ",n]});const r=function(e){var t,a;const n=(null===(t=e.PathDescription)||void 0===t?void 0:t.ReplicationDescription)||{},r=n.State,s=(null===(a=n.Config)||void 0===a?void 0:a.SrcConnectionParams)||{},{Endpoint:i,Database:o}=s,l=[];r&&l.push({name:Nr("state.label"),content:(0,d.jsx)(gr,{state:r})});i&&l.push({name:Nr("srcConnection.endpoint.label"),copyText:i,content:(0,d.jsx)(it.E,{variant:"code-inline-2",children:i})});o&&l.push({name:Nr("srcConnection.database.label"),copyText:o,content:(0,d.jsx)(it.E,{variant:"code-inline-2",children:o})});s&&l.push({name:Nr("credentials.label"),content:(0,d.jsx)(Sr,{connection:s})});return l}(e);return(0,d.jsxs)(ot.s,{direction:"column",gap:"4",children:[(0,d.jsx)(dr,{title:n,items:r}),(0,d.jsx)(jr,{config:null===(t=e.PathDescription)||void 0===t||null===(a=t.ReplicationDescription)||void 0===a?void 0:a.Config})]})}const wr=JSON.parse('{"writeLagPopover":"Write lag, maximum among all topic partitions","writeIdleTimePopover":"Write idle time, maximum among all topic partitions"}'),Cr=JSON.parse('{"writeLagPopover":"\u041b\u0430\u0433 \u0437\u0430\u043f\u0438\u0441\u0438, \u043c\u0430\u043a\u0441\u0438\u043c\u0430\u043b\u044c\u043d\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0441\u0440\u0435\u0434\u0438 \u0432\u0441\u0435\u0445 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439 \u0442\u043e\u043f\u0438\u043a\u0430","writeIdleTimePopover":"\u0412\u0440\u0435\u043c\u044f \u0431\u0435\u0437 \u0437\u0430\u043f\u0438\u0441\u0438, \u043c\u0430\u043a\u0441\u0438\u043c\u0430\u043b\u044c\u043d\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0441\u0440\u0435\u0434\u0438 \u0432\u0441\u0435\u0445 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439 \u0442\u043e\u043f\u0438\u043a\u0430"}'),Pr=(0,$e.g4)("ydb-diagnostics-overview-topic-stats",{ru:Cr,en:wr}),Ir=(0,c.cn)("ydb-overview-topic-stats"),Dr=e=>[{label:"Store size",value:(0,he.z3)(e.storeSize)},{label:(0,d.jsx)(Ra,{text:"Write idle time",popoverContent:(0,d.jsx)(Wa,{text:Pr("writeIdleTimePopover"),type:"write"})}),value:(0,vt.Bi)(e.partitionsIdleTime)},{label:(0,d.jsx)(Ra,{text:"Write lag",popoverContent:(0,d.jsx)(Wa,{text:Pr("writeLagPopover"),type:"write"})}),value:(0,vt.Bi)(e.partitionsWriteLag)},{label:"Average write speed",value:(0,d.jsx)(wa,{data:e.writeSpeed,withValue:!1})}],Ar=e=>{const t=e.writeSpeed;return[{label:"per minute",value:(0,he.tC)(t.perMinute)},{label:"per hour",value:(0,he.tC)(t.perHour)},{label:"per day",value:(0,he.tC)(t.perDay)}]},_r=({path:e,database:t})=>{const[a]=(0,X.Nt)(),{currentData:r,isFetching:s,error:i}=va.useGetTopicQuery({path:e,database:t},{pollingInterval:a}),o=s&&void 0===r,l=(0,X.N4)((a=>fa(a,e,t)));if(o)return(0,d.jsx)("div",{className:Ir(),children:(0,d.jsx)(ue.a,{size:"s"})});const c=i||!l?(0,d.jsx)(de.o,{error:i}):null;return(0,d.jsxs)("div",{className:Ir(),children:[(0,d.jsx)("div",{className:Ir("title"),children:"Stats"}),c,l?(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)("div",{className:Ir("info"),children:(0,d.jsx)(En.z_,{info:Dr(l),multilineLabels:!0})}),(0,d.jsx)("div",{className:Ir("bytes-written"),children:(0,d.jsx)(En.z_,{info:Ar(l)})})]}):null]})},Rr=e=>{var t;const a=null===e||void 0===e||null===(t=e.PathDescription)||void 0===t?void 0:t.PersQueueGroup;if(!a)return[];const{Partitions:n=[],PQTabletConfig:r={PartitionConfig:{LifetimeSeconds:0}}}=a,{Codecs:s,MeteringMode:i}=r,{WriteSpeedInBytesPerSecond:o,StorageLimitBytes:l}=r.PartitionConfig;return[...(0,En.jl)(On,{Partitions:n,PQTabletConfig:r}),...(0,En.jl)(Ln,{StorageLimitBytes:l,WriteSpeedInBytesPerSecond:o}),...(0,En.jl)(Mn,{Codecs:s,MeteringMode:i})]},kr=(e,t)=>{var a,n,r;if(!e&&!t)return[];const s=null===e||void 0===e||null===(a=e.PathDescription)||void 0===a?void 0:a.CdcStreamDescription,{Mode:i,Format:o}=s||{};return[Dn("CreateStep",null===e||void 0===e||null===(n=e.PathDescription)||void 0===n||null===(r=n.Self)||void 0===r?void 0:r.CreateStep),...(0,En.jl)(zn,{Mode:i,Format:o}),...Rr(t)]},Or=({path:e,database:t,data:a,topic:n})=>{const r=wn(null===a||void 0===a?void 0:a.PathDescription);return a&&n?(0,d.jsxs)("div",{children:[(0,d.jsx)(En.z_,{title:r,info:kr(a,n)}),(0,d.jsx)(_r,{path:e,database:t})]}):(0,d.jsxs)("div",{className:"error",children:["No ",r," data"]})},Mr=JSON.parse('{"page.title":"Database","pages.query":"Query","pages.diagnostics":"Diagnostics","summary.navigation":"Navigation","summary.showPreview":"Show preview","summary.source-type":"Source Type","summary.data-source":"Data Source","summary.copySchemaPath":"Copy schema path","summary.type":"Type","summary.subtype":"SubType","summary.id":"Id","summary.version":"Version","summary.created":"Created","summary.data-size":"Data size","summary.row-count":"Row count","summary.partitions":"Partitions count","summary.paths":"Paths","summary.shards":"Shards","summary.state":"State","summary.mode":"Mode","summary.format":"Format","summary.retention":"Retention","label.read-only":"ReadOnly","actions.copied":"The path is copied to the clipboard","actions.notCopied":"Couldn\u2019t copy the path","actions.copyPath":"Copy path","actions.connectToDB":"Connect to DB","actions.dropIndex":"Drop index","actions.openPreview":"Open preview","actions.createTable":"Create table...","actions.createExternalTable":"Create external table...","actions.createTopic":"Create topic...","actions.createColumnTable":"Create column table...","actions.createAsyncReplication":"Create async replication...","actions.createView":"Create view...","actions.dropTable":"Drop table...","actions.dropTopic":"Drop topic...","actions.dropView":"Drop view...","actions.alterTable":"Alter table...","actions.addTableIndex":"Add index...","actions.createCdcStream":"Create changefeed...","actions.alterTopic":"Alter topic...","actions.selectQuery":"Select query...","actions.upsertQuery":"Upsert query...","actions.alterReplication":"Alter async replicaton...","actions.dropReplication":"Drop async replicaton...","actions.createDirectory":"Create directory","schema.tree.dialog.placeholder":"Relative path","schema.tree.dialog.invalid":"Invalid path","schema.tree.dialog.whitespace":"Whitespace is not allowed","schema.tree.dialog.empty":"Path is empty","schema.tree.dialog.header":"Create directory","schema.tree.dialog.description":"Inside","schema.tree.dialog.buttonCancel":"Cancel","schema.tree.dialog.buttonApply":"Create"}'),Lr=(0,$e.g4)("ydb-tenant",{en:Mr});function zr({data:e}){const t=wn(e);return Cn(e)?(0,d.jsxs)(ot.s,{gap:1,wrap:"nowrap",children:[t," ",(0,d.jsx)(Ct.J,{children:Lr("label.read-only")})]}):t}const Fr=JSON.parse('{"tableStats":"Table Stats","tabletMetrics":"Tablet Metrics","partitionConfig":"Partition Config","label.ttl":"TTL for rows","value.ttl":"column: \'{{columnName}}\', expire after: {{expireTime}}","label.standalone":"Standalone","label.partitioning":"Partitioning","label.partitioning-by-size":"Partitioning by size","value.partitioning-by-size.enabled":"Enabled, split size: {{size}}","label.partitioning-by-load":"Partitioning by load","label.partitions-min":"Min number of partitions","label.partitions-max":"Max number of partitions","label.read-replicas":"Read replicas (followers)","label.bloom-filter":"Bloom filter","enabled":"Enabled","disabled":"Disabled"}'),qr=(0,$e.g4)("ydb-diagnostics-overview-table-info",{en:Fr});var Qr=a(62091),Ur=a.n(Qr),Br=a(7435),$r=a(41650);const Hr=e=>{if(e.Enabled&&e.Enabled.ColumnName&&void 0!==e.Enabled.ExpireAfterSeconds){const t=qr("value.ttl",{columnName:e.Enabled.ColumnName,expireTime:(0,vt.Bi)(1e3*e.Enabled.ExpireAfterSeconds,1)});return{label:qr("label.ttl"),value:t}}};const Gr=(e,t)=>{if(!e)return{};const{PathDescription:a={}}=e,{TableStats:n={},TabletMetrics:r={},Table:{PartitionConfig:s={},TTLSettings:i}={},ColumnTableDescription:o={}}=a,{PartCount:l,RowCount:c,DataSize:u,IndexSize:m,ByKeyFilterSize:p,LastAccessTime:h,LastUpdateTime:v,ImmediateTxCompleted:g,PlannedTxCompleted:y,TxRejectedByOverload:b,TxRejectedBySpace:f,TxCompleteLagMsec:j,InFlightTxCount:S,RowUpdates:T,RowDeletes:N,RowReads:E,RangeReads:w,RangeReadRows:C}=n,{FollowerGroups:P,FollowerCount:I,CrossDataCenterFollowerCount:D}=s;let A=[];switch(t){case x.EPathTypeTable:A=((e,t)=>{var a;const{PartitioningPolicy:n={},FollowerGroups:r,EnableFilterByKey:s}=e,i=[],o=n.SizeToSplit&&Number(n.SizeToSplit)>0?qr("value.partitioning-by-size.enabled",{size:(0,he.z3)(n.SizeToSplit)}):qr("disabled"),l=null!==(a=n.SplitByLoadSettings)&&void 0!==a&&a.Enabled?qr("enabled"):qr("disabled");if(i.push({label:qr("label.partitioning-by-size"),value:o},{label:qr("label.partitioning-by-load"),value:l},{label:qr("label.partitions-min"),value:(0,he.ZV)(n.MinPartitionsCount||0)}),n.MaxPartitionsCount&&i.push({label:qr("label.partitions-max"),value:(0,he.ZV)(n.MaxPartitionsCount)}),r&&r.length){const{RequireAllDataCenters:e,FollowerCountPerDataCenter:t,FollowerCount:a}=r[0];let n;n=e&&t?`PER_AZ: ${a}`:`ANY_AZ: ${a}`,i.push({label:qr("label.read-replicas"),value:n})}if(t){const e=Hr(t);e&&i.push(e)}return(0,Br.f8)(s)&&i.push({label:qr("label.bloom-filter"),value:qr(s?"enabled":"disabled")}),i})(s,i);break;case x.EPathTypeColumnTable:A=function(e){var t,a;const n=[];var r;if(n.push({label:qr("label.standalone"),value:String((r=e,!(r.SchemaPresetName&&void 0!==r.SchemaPresetId)))}),null!==(t=e.Sharding)&&void 0!==t&&null!==(a=t.HashSharding)&&void 0!==a&&a.Columns){const t=`PARTITION BY HASH(${e.Sharding.HashSharding.Columns.join(", ")})`;n.push({label:qr("label.partitioning"),value:(0,d.jsx)(it.E,{variant:"code-2",wordBreak:"break-word",children:t})})}if(e.TtlSettings){const t=Hr(null===e||void 0===e?void 0:e.TtlSettings);t&&n.push(t)}return n}(o)}const _=(0,En.jl)(Un,{PartCount:l,RowCount:c,DataSize:u,IndexSize:m});(0,$r.kf)(p)&&(s.EnableFilterByKey||Number(p)>0)&&_.push({label:"BloomFilterSize",value:_n(p)});const R=[_,(0,En.jl)(Un,{LastAccessTime:h,LastUpdateTime:v}),(0,En.jl)(Un,{ImmediateTxCompleted:g,PlannedTxCompleted:y,TxRejectedByOverload:b,TxRejectedBySpace:f,TxCompleteLagMsec:j,InFlightTxCount:S}),(0,En.jl)(Un,{RowUpdates:T,RowDeletes:N,RowReads:E,RangeReads:w,RangeReadRows:C})],k=(0,En.jl)(Fn,Ur()(r,["GroupReadIops","GroupReadThroughput","GroupWriteIops","GroupWriteThroughput"]));let O=[];return Array.isArray(P)&&P.length>0?O=(0,En.jl)(qn,P[0]):void 0!==I?O.push(Qn("FollowerCount",I)):void 0!==D&&O.push(Qn("CrossDataCenterFollowerCount",D)),{generalInfo:A,tableStatsInfo:R,tabletMetricsInfo:k,partitionConfigInfo:O}},Wr=(0,c.cn)("ydb-diagnostics-table-info"),Vr=({data:e,type:t})=>{const a=(0,d.jsx)(zr,{data:null===e||void 0===e?void 0:e.PathDescription}),{generalInfo:r,tableStatsInfo:s,tabletMetricsInfo:i=[],partitionConfigInfo:o=[]}=n.useMemo((()=>Gr(e,t)),[e,t]);return(0,d.jsxs)("div",{className:Wr(),children:[(0,d.jsx)(En.z_,{info:r,title:a,className:Wr("info-block"),renderEmptyState:()=>(0,d.jsx)("div",{className:Wr("title"),children:a})}),(0,d.jsxs)("div",{className:Wr("row"),children:[s?(0,d.jsx)("div",{className:Wr("col"),children:s.map(((e,t)=>(0,d.jsx)(En.z_,{info:e,title:0===t?qr("tableStats"):void 0,className:Wr("info-block"),renderEmptyState:()=>null},t)))}):null,i.length>0||o.length>0?(0,d.jsxs)("div",{className:Wr("col"),children:[(0,d.jsx)(En.z_,{info:i,title:qr("tabletMetrics"),className:Wr("info-block"),renderEmptyState:()=>null}),(0,d.jsx)(En.z_,{info:o,title:qr("partitionConfig"),className:Wr("info-block"),renderEmptyState:()=>null})]}):null]})]})},Jr=({data:e,path:t,database:a})=>{const n=wn(null===e||void 0===e?void 0:e.PathDescription);return e?(0,d.jsxs)("div",{children:[(0,d.jsx)(En.z_,{title:n,info:Rr(e)}),(0,d.jsx)(_r,{path:t,database:a})]}):(0,d.jsxs)("div",{className:"error",children:["No ",n," data"]})};const Yr=function({type:e,path:t,database:a}){const[r]=(0,X.Nt)(),s=z(e),i=(0,X.N4)((n=>J(n,t,e,a)),pn.bN);let o=[];s?i&&(o=[t,...i]):o=[t];const{mergedDescribe:l,loading:c,error:u}=Y({paths:o,database:a,autoRefreshInterval:r}),m=l[t];return c||s&&!i?(0,d.jsx)(ue.a,{size:"m"}):(0,d.jsxs)(n.Fragment,{children:[u?(0,d.jsx)(de.o,{error:u}):null,u&&!m?null:(()=>{var n;const r=null!==m&&void 0!==m?m:void 0,s={[x.EPathTypeInvalid]:void 0,[x.EPathTypeDir]:void 0,[x.EPathTypeTable]:void 0,[x.EPathTypeSubDomain]:void 0,[x.EPathTypeTableIndex]:()=>(0,d.jsx)($n,{data:r}),[x.EPathTypeExtSubDomain]:void 0,[x.EPathTypeColumnStore]:void 0,[x.EPathTypeColumnTable]:void 0,[x.EPathTypeCdcStream]:()=>{const e=null===i||void 0===i?void 0:i[0];var n;if(e)return(0,d.jsx)(Or,{path:t,database:a,data:r,topic:null!==(n=null===l||void 0===l?void 0:l[e])&&void 0!==n?n:void 0})},[x.EPathTypePersQueueGroup]:()=>(0,d.jsx)(Jr,{data:r,path:t,database:a}),[x.EPathTypeExternalTable]:()=>(0,d.jsx)(sr,{data:r}),[x.EPathTypeExternalDataSource]:()=>(0,d.jsx)(Zn,{data:r}),[x.EPathTypeView]:()=>(0,d.jsx)(vr,{data:r}),[x.EPathTypeReplication]:()=>(0,d.jsx)(Er,{data:r})};return e&&(null===(n=s[e])||void 0===n?void 0:n.call(s))||(0,d.jsx)(Vr,{data:r,type:e})})()]})};var Kr,Zr=a(74417);function Xr(){return Xr=Object.assign?Object.assign.bind():function(e){for(var t=1;t({getChartData:e.query({queryFn:async(e,{signal:t})=>{try{const a=await(async({database:e,metrics:t,timeFrame:a,maxDataPoints:n},{signal:r}={})=>{const s=t.map((e=>`target=${e.target}`)).join("&"),i=Math.round(Date.now()/1e3),o=i-ms[a];return window.api.viewer.getChartData({target:s,from:o,until:i,maxDataPoints:n,database:e},{signal:r})})(e,{signal:t});if(Array.isArray(a)){return{data:((e=[],t)=>{const a=e.map((({datapoints:e,target:a})=>{const n=t.find((e=>e.target===a));if(!n)return;const r=e.map((e=>e[0]));return{...n,data:r}})).filter((e=>void 0!==e));return{timeline:e[0].datapoints.map((e=>1e3*e[1])),metrics:a}})(a,e.metrics)}}return{error:new Error("string"===typeof a?hs("not-supported"):a.error)}}catch(a){return{error:a}}},providesTags:["All"],keepUnusedDataFor:0})}),overrideExisting:"throw"}),gs=(0,c.cn)("ydb-metric-chart");ns.W.set({plugins:[ss.YagrPlugin]});const ys=(e,t={})=>{const{dataType:a,scaleRange:n,showLegend:r}=t,s=(e=>{switch(e){case"ms":return ls;case"size":return cs;case"percent":return ds;default:return}})(a),i=!e.metrics.length,o=e.metrics.map(((e,t)=>{const a=e.color||os[t],n=function(e,t){const a=(0,is.Mj)(e);if(!a.isValid())throw new Error("Invalid color is passed");return a.alpha(t).toRgbString()}(a,.1);return{id:e.target,name:e.title||e.target,data:e.data,formatter:s,lineColor:a,color:n,legendColorKey:"lineColor"}}));return{data:{timeline:e.timeline,graphs:o},libraryConfig:{chart:{size:{padding:i?[10,0,10,0]:void 0},series:{type:"area",spanGaps:!0,lineWidth:1.5},select:{zoom:!1}},scales:{y:{type:"linear",range:"nice",min:(null===n||void 0===n?void 0:n.min)||0,max:null===n||void 0===n?void 0:n.max}},axes:{y:{values:s?(e,t)=>t.map(s):void 0}},tooltip:{show:!0,tracking:"sticky"},legend:{show:r}}}},xs={timeline:[],metrics:[]},bs=({database:e,title:t,metrics:a,timeFrame:r="1h",autorefresh:s,width:i=400,height:o=i/1.5,chartOptions:l,onChartDataStatusChange:c,isChartVisible:u})=>{const{currentData:m,error:p,isFetching:h,status:v}=vs.useGetChartDataQuery({database:e,metrics:a,timeFrame:r,maxDataPoints:i/2},{pollingInterval:s}),g=h&&!m;n.useEffect((()=>null===c||void 0===c?void 0:c("fulfilled"===v?"success":"loading")),[v,c]);const y=ys(m||xs,l);return(0,d.jsxs)("div",{className:gs(null),style:{height:o,width:i},children:[(0,d.jsx)("div",{className:gs("title"),children:t}),g?(0,d.jsx)(ue.a,{}):u?(0,d.jsxs)("div",{className:gs("chart"),children:[(0,d.jsx)(rs.Ay,{type:"yagr",data:y}),p?(0,d.jsx)(de.o,{className:gs("error"),error:p}):null]}):null]})},fs=(0,c.cn)("ydb-timeframe-selector"),js=({value:e,onChange:t,className:a})=>(0,d.jsx)("div",{className:fs(null,a),children:Object.keys(ms).map((a=>(0,d.jsx)(hn.$,{view:"flat",selected:e===a,onClick:()=>t(a),children:a},a)))}),Ss=(0,c.cn)("ydb-tenant-dashboard"),Ts=({database:e,charts:t})=>{const[a,r]=n.useState(!0),[i="1h",o]=(0,s.useQueryParam)("timeframe",s.StringParam),[l]=(0,X.Nt)(),c=a?0:l,u=e=>{"success"===e&&r(!1)},m=1===t.length?872:428,p=428/1.5;return(0,d.jsxs)("div",{className:Ss(null),style:{display:a?"none":void 0},children:[(0,d.jsx)("div",{className:Ss("controls"),children:(0,d.jsx)(js,{value:i,onChange:o})}),(0,d.jsx)("div",{className:Ss("charts"),children:t.map((t=>{const n=t.metrics.map((({target:e})=>e)).join("&");return(0,d.jsx)(bs,{database:e,title:t.title,metrics:t.metrics,timeFrame:i,chartOptions:t.options,autorefresh:c,width:m,height:p,onChartDataStatusChange:u,isChartVisible:!a},n)}))})]})},Ns=JSON.parse('{"no-data":"No data","no-pools-data":"No pools data","top-nodes.empty-data":"No such nodes","top-groups.empty-data":"No such groups","top":"Top","nodes":"nodes","shards":"shards","groups":"groups","queries":"queries","tables":"tables","by-pools-usage":"by pools usage","by-cpu-time":"by cpu time, {{executionPeriod}}","by-cpu-usage":"by cpu usage","by-load":"by load","by-memory":"by memory","by-usage":"by usage","by-size":"by size","cards.cpu-label":"CPU","cards.storage-label":"Storage","cards.memory-label":"Memory","charts.queries-per-second":"Queries per second","charts.transaction-latency":"Transactions latencies {{percentile}}","charts.cpu-usage":"CPU usage by pool","charts.storage-usage":"Tablet storage usage","charts.memory-usage":"Memory usage","storage.tablet-storage-title":"Tablet storage","storage.tablet-storage-description":"Size of user data and indexes stored in schema objects (tables, topics, etc.)","storage.db-storage-title":"Database storage","storage.db-storage-description":"Size of data stored in distributed storage with all overheads for redundancy","executed-last-hour":"executed in the last hour","column-header.process":"Process"}'),Es=(0,$e.g4)("ydb-diagnostics-tenant-overview",{en:Ns}),ws=[{title:Es("charts.queries-per-second"),metrics:[{target:"queries.requests",title:Es("charts.queries-per-second")}]},{title:Es("charts.transaction-latency",{percentile:""}),metrics:[{target:"queries.latencies.p50",title:"p50"},{target:"queries.latencies.p75",title:"p75"},{target:"queries.latencies.p90",title:"p90"},{target:"queries.latencies.p99",title:"p99"}],options:{dataType:"ms",showLegend:!0}}],Cs=({database:e})=>(0,d.jsx)(Ts,{database:e,charts:ws});var Ps=a(67157);const Is=H.F.injectEndpoints({endpoints:e=>({getHealthcheckInfo:e.query({queryFn:async({database:e,maxLevel:t},{signal:a})=>{try{return{data:await window.api.viewer.getHealthcheckInfo({database:e,maxLevel:t},{signal:a})}}catch(n){return{error:n}}},providesTags:["All"]})}),overrideExisting:"throw"}),Ds={RED:0,ORANGE:1,YELLOW:2,BLUE:3,GREEN:4},As=e=>e.sort(((e,t)=>(Ds[e.status]||0)-(Ds[t.status]||0))),_s=({issue:e,data:t})=>As(t.filter((t=>e.reason&&-1!==e.reason.indexOf(t.id)))),Rs=({data:e,roots:t})=>t?t.map((t=>{const a=Rs({roots:_s({issue:t,data:e}),data:e});return{...t,reasonsItems:a}})):[],ks=(0,g.Mz)((e=>e),(e=>Is.endpoints.getHealthcheckInfo.select({database:e}))),Os=(0,g.Mz)((e=>e),((e,t)=>ks(t)),((e,t)=>{var a;return(null===(a=t(e).data)||void 0===a?void 0:a.issue_log)||[]})),Ms=(0,g.Mz)(Os,((e=[])=>{return As((t=e).filter((e=>!t.find((t=>t.reason&&-1!==t.reason.indexOf(e.id))))));var t})),Ls=(0,g.Mz)([Os,Ms],((e=[],t=[])=>Rs({data:e,roots:t}))),zs=(0,g.Mz)(Os,((e=[])=>(e=>{const t={};for(const a of e)t[a.status]||(t[a.status]=0),t[a.status]++;return Object.entries(t).sort((([e],[t])=>(Ds[e]||0)-(Ds[t]||0)))})(e)));let Fs=function(e){return e.UNSPECIFIED="UNSPECIFIED",e.GOOD="GOOD",e.DEGRADED="DEGRADED",e.MAINTENANCE_REQUIRED="MAINTENANCE_REQUIRED",e.EMERGENCY="EMERGENCY",e}({}),qs=function(e){return e.UNSPECIFIED="UNSPECIFIED",e.GREY="GREY",e.GREEN="GREEN",e.BLUE="BLUE",e.YELLOW="YELLOW",e.ORANGE="ORANGE",e.RED="RED",e}({});var Qs=a(63126),Us=a(54090);const Bs={[qs.UNSPECIFIED]:Us.m.Grey,[qs.GREY]:Us.m.Grey,[qs.GREEN]:Us.m.Green,[qs.BLUE]:Us.m.Blue,[qs.YELLOW]:Us.m.Yellow,[qs.ORANGE]:Us.m.Orange,[qs.RED]:Us.m.Red},$s=(0,c.cn)("issue-tree-item"),Hs=({status:e,message:t,type:a,onClick:n})=>(0,d.jsxs)("div",{className:$s(),onClick:n,children:[(0,d.jsx)("div",{className:$s("field",{status:!0}),children:(0,d.jsx)(Hn.c,{mode:"icons",status:e,name:a})}),(0,d.jsx)("div",{className:$s("field",{message:!0}),children:t})]}),Gs=(0,c.cn)("issue-tree"),Ws=({issueTree:e})=>{const[t,a]=n.useState({}),r=n.useCallback((e=>e?(0,d.jsx)("div",{className:Gs("info-panel"),children:(0,d.jsx)(jn,{data:e,search:!1,isExpanded:()=>!0,treeClassName:Gs("inspector")})}):null),[]),s=n.useCallback((e=>e.map((e=>{const{id:n}=e,{status:i,message:o,type:l,reasonsItems:c,level:u,...m}=e,p="undefined"===typeof t[n]||t[n],h=()=>{a((e=>({...e,[n]:!p})))};return(0,d.jsxs)(Qs.G,{name:(0,d.jsx)(Hs,{status:Bs[i],message:o,type:l}),collapsed:p,hasArrow:!0,onClick:h,onArrowClick:h,level:u-1,children:[r(Ur()(m,["reason"])),s(c||[])]},n)}))),[t,r]);return(0,d.jsx)("div",{className:Gs(),children:(0,d.jsx)("div",{className:Gs("block"),children:s([e])})})},Vs=JSON.parse('{"title.healthcheck":"Healthcheck","label.update":"Update","label.show-details":"Show details","label.issues":"Issues:","status_message.ok":"No issues","no-data":"no healthcheck data"}'),Js=JSON.parse('{"title.healthcheck":"Healthcheck","label.update":"\u041e\u0431\u043d\u043e\u0432\u0438\u0442\u044c","label.show-details":"\u041f\u043e\u0441\u043c\u043e\u0442\u0440\u0435\u0442\u044c \u043f\u043e\u0434\u0440\u043e\u0431\u043d\u043e\u0441\u0442\u0438","label.issues":"\u041f\u0440\u043e\u0431\u043b\u0435\u043c\u044b:","status_message.ok":"\u041d\u0435\u0442 \u043f\u0440\u043e\u0431\u043b\u0435\u043c","no-data":"\u043d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445 healthcheck"}'),Ys=(0,$e.g4)("ydb-diagnostics-healthcheck",{ru:Js,en:Vs}),Ks=(0,c.cn)("healthcheck");function Zs({tenantName:e}){const[t]=(0,X.Nt)(),{name:a}=(0,Ps.Zd)(),{issueTrees:r,loading:s,error:i}=((e,{autorefresh:t}={})=>{const{currentData:a,isFetching:n,error:r,refetch:s}=Is.useGetHealthcheckInfoQuery({database:e},{pollingInterval:t}),i=(null===a||void 0===a?void 0:a.self_check_result)||Fs.UNSPECIFIED,o=(0,X.N4)((t=>zs(t,e)));return{issueTrees:(0,X.N4)((t=>Ls(t,e))),issuesStatistics:o,loading:void 0===a&&n,error:r,refetch:s,selfCheckResult:i}})(e,{autorefresh:"ydb_ru"===a?void 0:t});return(0,d.jsx)("div",{className:Ks("details"),children:(0,d.jsx)("div",{className:Ks("details-content-wrapper"),children:i?(0,d.jsx)(de.o,{error:i,defaultMessage:Ys("no-data")}):s?(0,d.jsx)(ue.a,{size:"m"}):r&&r.length?(0,d.jsx)(n.Fragment,{children:r.map((e=>(0,d.jsx)(Ws,{issueTree:e},e.id)))}):Ys("status_message.ok")})})}var Xs=a(8861),ei=a(73633),ti=a(70825),ai=a(43937),ni=a(10800),ri=a(71153),si=a(2102),ii=a(52358);const oi=(0,c.cn)("healthcheck"),li={[Fs.UNSPECIFIED]:ei.A,[Fs.GOOD]:ti.A,[Fs.DEGRADED]:ai.A,[Fs.MAINTENANCE_REQUIRED]:ni.A,[Fs.EMERGENCY]:ri.A};function ci(e){const{tenantName:t,active:a}=e,[n]=(0,X.Nt)(),{name:r}=(0,Ps.Zd)(),s="ydb_ru"===r,{currentData:i,isFetching:o,error:l}=Is.useGetHealthcheckInfoQuery({database:t},{pollingInterval:s?void 0:n}),c=o&&void 0===i;return(0,d.jsxs)(si.A,{className:oi("preview"),active:a,children:[(0,d.jsx)("div",{className:oi("preview-header"),children:(0,d.jsxs)("div",{className:oi("preview-title-wrapper"),children:[(0,d.jsx)("div",{className:oi("preview-title"),children:Ys("title.healthcheck")}),n&&s?(0,d.jsx)(sa.A,{content:"Autorefresh is disabled. Please update healthcheck manually.",placement:["top"],className:oi("icon-wrapper"),children:()=>(0,d.jsx)(ct.I,{size:16,className:oi("icon-warn"),data:ii.A})}):null]})}),(()=>{if(l)return(0,d.jsx)(de.o,{error:l,defaultMessage:Ys("no-data")});if(c)return(0,d.jsx)(ue.a,{size:"m"});const e=(null===i||void 0===i?void 0:i.self_check_result)||Fs.UNSPECIFIED,t=e.toLowerCase();return(0,d.jsx)("div",{className:oi("preview-content"),children:(0,d.jsxs)("div",{className:oi("preview-issue",{[t]:!0}),children:[(0,d.jsx)(ct.I,{className:oi("preview-status-icon"),data:li[e]}),(0,d.jsx)("div",{className:oi("self-check-status-indicator"),children:e.replace(/_/g," ")})]})})})()]})}var di=a(15132),ui=a(33775);const mi=(0,c.cn)("ydb-metrics-card"),pi=e=>{let t;return"Warning"===e&&(t=Us.m.Yellow),"Danger"===e&&(t=Us.m.Red),t?(0,d.jsx)(ui.k,{status:t,mode:"icons",size:"l"}):null};function hi({active:e,label:t,status:a,metrics:n}){return(0,d.jsxs)(si.A,{className:mi({active:e}),active:e,children:[(0,d.jsxs)("div",{className:mi("header"),children:[t&&(0,d.jsx)("div",{className:mi("label"),children:t}),pi(a)]}),(0,d.jsx)("div",{className:mi("content"),children:n.map((({title:e,...t},a)=>(0,d.jsxs)("div",{className:mi("metric"),children:[(0,d.jsx)("div",{className:mi("metric-title"),children:e}),(0,d.jsx)(di.O,{size:"xs",colorizeProgress:!0,...t})]},a)))})]})}const vi=(0,c.cn)("metrics-cards");function gi({poolsCpuStats:e,memoryStats:t,blobStorageStats:a,tabletStorageStats:n,tenantName:r}){const s=(0,Xn.zy)(),{metricsTab:i}=(0,X.N4)((e=>e.tenant)),o=(0,ye.mA)(s),l=e=>e===i?"":e,c={[ae.pA.cpu]:(0,na.YL)({...o,[na.vh.metricsTab]:l(ae.pA.cpu)}),[ae.pA.storage]:(0,na.YL)({...o,[na.vh.metricsTab]:l(ae.pA.storage)}),[ae.pA.memory]:(0,na.YL)({...o,[na.vh.metricsTab]:l(ae.pA.memory)}),[ae.pA.healthcheck]:(0,na.YL)({...o,[na.vh.metricsTab]:l(ae.pA.healthcheck)})};return(0,d.jsxs)("div",{className:vi(),children:[(0,d.jsx)(re.N_,{to:c.cpu,className:vi("tab"),children:(0,d.jsx)(yi,{poolsCpuStats:e,active:i===ae.pA.cpu})}),(0,d.jsx)(re.N_,{to:c.storage,className:vi("tab"),children:(0,d.jsx)(xi,{blobStorageStats:a,tabletStorageStats:n,active:i===ae.pA.storage})}),(0,d.jsx)(re.N_,{to:c.memory,className:vi("tab"),children:(0,d.jsx)(bi,{memoryStats:t,active:i===ae.pA.memory})}),(0,d.jsx)(re.N_,{to:c.healthcheck,className:vi("tab"),children:(0,d.jsx)(ci,{tenantName:r,active:i===ae.pA.healthcheck})})]})}function yi({poolsCpuStats:e=[],active:t}){let a=Xs.u.Unspecified;const n=e.filter((e=>!("Batch"===e.name||"IO"===e.name))).map((e=>{const{name:t,usage:n,limit:r,used:s}=e,i=(0,as.sf)(n);return Xs.Z[i]>Xs.Z[a]&&(a=i),{title:t,value:s,capacity:r}}));return(0,d.jsx)(hi,{label:Es("cards.cpu-label"),active:t,metrics:n,status:a})}function xi({blobStorageStats:e=[],tabletStorageStats:t,active:a}){let n=Xs.u.Unspecified;const r=(t||e).map((e=>{const{name:t,used:a,limit:r,usage:s}=e,i=(0,as.sf)(s);return Xs.Z[i]>Xs.Z[n]&&(n=i),{title:t,value:a,capacity:r,formatValues:he.j9}}));return(0,d.jsx)(hi,{label:Es("cards.storage-label"),active:a,metrics:r,status:n})}function bi({active:e,memoryStats:t=[]}){let a=Xs.u.Unspecified;const n=t.map((e=>{const{name:t,used:n,limit:r,usage:s}=e,i=(0,as.sf)(s);return Xs.Z[i]>Xs.Z[a]&&(a=i),{title:t,value:n,capacity:r,formatValues:he.j9}}));return(0,d.jsx)(hi,{label:Es("cards.memory-label"),active:e,metrics:n,status:a})}var fi=a(78762),ji=a(86782),Si=a(15298),Ti=a(40781);const Ni=(0,c.cn)("tenant-overview");function Ei({title:e,error:t,loading:a,tableClassNameModifiers:r={},...s}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)("div",{className:Ni("title"),children:e}),t?(0,d.jsx)(de.o,{error:t}):null,(0,d.jsx)("div",{className:Ni("table",r),children:t&&0===s.data.length?null:a?(0,d.jsx)(Tt.Q,{rows:Z.Nz}):(0,d.jsx)(Fe.l,{settings:Z.jp,...s})})]})}var wi=a(82015);const Ci=({prefix:e=Es("top"),entity:t,postfix:a,link:r,onClick:s})=>r?(0,d.jsxs)(n.Fragment,{children:[e," ",(0,d.jsx)(wi.E,{to:r,onClick:s,children:t})," ",a]}):`${e} ${t} ${a}`;function Pi({tenantName:e,additionalNodesProps:t}){const a=(0,X.e4)(),[n]=(0,X.Nt)(),[r,s]=function(e){const t={...(0,fi.Nh)(e),width:void 0},a=[(0,fi.kv)(),(0,fi._E)(),t].map((e=>({...e,sortable:!1}))),n=a.map((e=>e.name));return[a,(0,Ti.R)(n,ji.fN)]}({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef,database:e}),{currentData:i,isFetching:o,error:l}=Si.s.useGetNodesQuery({tenant:e,type:"any",sort:"-CPU",limit:Z.Nz,tablets:!1,fieldsRequired:s},{pollingInterval:n}),c=o&&void 0===i,u=(null===i||void 0===i?void 0:i.Nodes)||[],m=Ci({entity:Es("nodes"),postfix:Es("by-pools-usage"),link:(0,na.YL)({...a,[na.vh.diagnosticsTab]:ae.iJ.nodes})});return(0,d.jsx)(Ei,{columnsWidthLSKey:ji.zO,data:u,columns:r,title:m,loading:c,error:l,emptyDataMessage:Es("top-nodes.empty-data")})}function Ii({tenantName:e,additionalNodesProps:t}){const a=(0,X.e4)(),[n]=(0,X.Nt)(),[r,s]=function(e){const t={...(0,fi.Nh)(e),width:void 0},a=[(0,fi.fR)(),(0,fi._E)(),t,(0,fi.Rn)()].map((e=>({...e,sortable:!1}))),n=a.map((e=>e.name));return[a,(0,Ti.R)(n,ji.fN)]}({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef,database:e}),{currentData:i,isFetching:o,error:l}=Si.s.useGetNodesQuery({tenant:e,type:"any",sort:"-LoadAverage",limit:Z.Nz,tablets:!1,fieldsRequired:s},{pollingInterval:n}),c=o&&void 0===i,u=(null===i||void 0===i?void 0:i.Nodes)||[],m=Ci({entity:Es("nodes"),postfix:Es("by-load"),link:(0,na.YL)({...a,[na.vh.diagnosticsTab]:ae.iJ.nodes})});return(0,d.jsx)(Ei,{columnsWidthLSKey:ji.zO,data:u,columns:r,title:m,loading:c,error:l,emptyDataMessage:Es("top-nodes.empty-data")})}var Di=a(69053),Ai=a(10468),_i=a(16332),Ri=a(2198);const ki=JSON.parse('{"action_cancel":"Cancel"}'),Oi=(0,$e.g4)("ydb-confirmation-dialog",{en:ki}),Mi=(0,c.cn)("confirmation-dialog"),Li="confirmation-dialog";function zi({caption:e="",children:t,onConfirm:a,onClose:n,progress:r,textButtonApply:s,textButtonCancel:i,buttonApplyView:o="normal",className:l,renderButtons:c,open:u}){return(0,d.jsxs)(Ri.l,{className:Mi(null,l),size:"s",onClose:n,disableOutsideClick:!0,open:u,children:[(0,d.jsx)(Ri.l.Header,{caption:(0,d.jsx)("span",{className:Mi("caption"),children:e})}),(0,d.jsx)(Ri.l.Body,{children:t}),(0,d.jsx)(Ri.l.Footer,{onClickButtonApply:a,propsButtonApply:{view:o},textButtonApply:s,textButtonCancel:null!==i&&void 0!==i?i:Oi("action_cancel"),onClickButtonCancel:n,loading:r,renderButtons:c})]})}const Fi=_i.vt((e=>{const t=_i.hS(),a=()=>{t.hide(),t.remove()};return(0,d.jsx)(zi,{...e,onConfirm:async()=>{var n;await(null===(n=e.onConfirm)||void 0===n?void 0:n.call(e)),t.resolve(!0),a()},onClose:()=>{var n;null===(n=e.onClose)||void 0===n||n.call(e),t.resolve(!1),a()},open:t.visible})}));_i.kz(Li,Fi);var qi=a(40569),Qi=a(28664),Ui=a(36894);function Bi(){const[e]=(0,X.iK)(Z.ld,[]),t=(0,X.N4)(Ui.cu).toLowerCase();return t?e.filter((e=>e.body.toLowerCase().includes(t))):e}const $i=JSON.parse('{"action.save":"Save query","action.edit":"Edit query","action.save-as-new":"Save as new","action.edit-existing":"Edit existing","description":"The query will be saved in your browser","input-label":"Query name","input-placeholder":"Enter query name","button-apply":"Save","button-cancel":"Cancel","error.name-exists":"This name already exists","error.name-not-empty":"Name should not be empty"}'),Hi=(0,$e.g4)("ydb-save-query-dialog",{en:$i}),Gi=(0,c.cn)("ydb-save-query");function Wi(e){const t=(0,X.YQ)();return n.useCallback((()=>{_i.Ay.show(Ki,e),t((0,Ui.gJ)())}),[t,e])}function Vi({dialogProps:e,...t}){const a=Wi(e);return(0,d.jsx)(hn.$,{onClick:a,...t,children:Hi("action.save")})}function Ji({buttonProps:e={}}){const t=(0,X.YQ)(),a=(0,X.N4)(Ui.aW),n=Wi(),r=()=>{t((0,Ui.Wg)(a)),t((0,Ui.gJ)())};return a?(()=>{const t=[{action:r,text:Hi("action.edit-existing")},{action:n,text:Hi("action.save-as-new")}];return(0,d.jsx)(qi.r,{items:t,renderSwitcher:t=>(0,d.jsx)(hn.$,{...t,...e,children:Hi("action.edit")}),popupProps:{placement:"top"}})})():(0,d.jsx)(Vi,{})}function Yi({onSuccess:e,onCancel:t,onClose:a,open:r}){const s=Bi(),i=(0,X.YQ)(),[o,l]=n.useState(""),[c,u]=n.useState(),m=()=>{i((0,Ui.NJ)("idle")),l(""),u(void 0),null===a||void 0===a||a()},p=()=>{null===t||void 0===t||t(),m()};return(0,d.jsxs)(Ri.l,{open:r,hasCloseButton:!1,size:"s",onClose:p,children:[(0,d.jsx)(Ri.l.Header,{caption:Hi("action.save")}),(0,d.jsxs)("form",{onSubmit:t=>{t.preventDefault();const a=(n=o)?s.some((e=>e.name.toLowerCase()===n.trim().toLowerCase()))?Hi("error.name-exists"):void 0:Hi("error.name-not-empty");var n;u(a),a||(i((0,Ui.Wg)(o)),m(),null===e||void 0===e||e())},children:[(0,d.jsxs)(Ri.l.Body,{className:Gi("dialog-body"),children:[(0,d.jsx)("div",{className:Gi("dialog-row"),children:Hi("description")}),(0,d.jsxs)("div",{className:Gi("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"queryName",className:Gi("field-title","required"),children:Hi("input-label")}),(0,d.jsx)("div",{className:Gi("control-wrapper"),children:(0,d.jsx)(Qi.k,{id:"queryName",placeholder:Hi("input-placeholder"),value:o,onUpdate:e=>{l(e),u(void 0)},hasClear:!0,autoFocus:!0,autoComplete:!1,validationState:c?"invalid":void 0,errorMessage:c})})]})]}),(0,d.jsx)(Ri.l.Footer,{textButtonApply:Hi("button-apply"),textButtonCancel:Hi("button-cancel"),onClickButtonCancel:p,propsButtonApply:{type:"submit"}})]})]})}const Ki="save-query-dialog",Zi=_i.Ay.create((e=>{const t=_i.Ay.useModal();return(0,d.jsx)(Yi,{...e,onClose:()=>{var a;null===(a=e.onClose)||void 0===a||a.call(e),t.hide(),t.remove()},open:t.visible})}));_i.Ay.register(Ki,Zi);const Xi=JSON.parse('{"action_apply":"Don\'t save","context_unsaved-changes-warning":"You have unsaved changes in query editor.\\nDo you want to proceed?"}'),eo=(0,$e.g4)("ydb-change-input-confirmation",{en:Xi});function to(){const e=_i.Ay.useModal(Li),t=n.useCallback((()=>{e.hide(),e.remove()}),[e]),a=n.useCallback((()=>{e.resolve(!0),t()}),[e,t]),r=n.useCallback((()=>{e.resolve(!1),t()}),[t,e]),s=n.useMemo((()=>({onSuccess:a,onCancel:r})),[a,r]);return(0,d.jsx)(Vi,{view:"action",size:"l",dialogProps:s})}async function ao(){return await _i.Ay.show(Li,{id:Li,caption:eo("context_unsaved-changes-warning"),textButtonApply:eo("action_apply"),propsButtonApply:{view:"l"},renderButtons:(e,t)=>(0,d.jsxs)(n.Fragment,{children:[t,(0,d.jsx)(to,{}),e]})})}function no(e){const t=(0,X.N4)(Ai.Wp),a=n.useMemo((()=>function(e){return async t=>{await ao()&&e(t)}}(e)),[e]);return t?a:e}const ro=(0,c.cn)("kv-truncated-query"),so=({value:e="",maxQueryHeight:t=6})=>{const a=e.split("\n");if(a.length>t){const e=a.slice(0,t).join("\n"),r="\n...\nThe request was truncated. Click on the line to show the full query on the query tab";return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(hr,{className:ro(),children:e}),(0,d.jsx)("span",{className:ro("message",{color:"secondary"}),children:r})]})}return(0,d.jsx)(hr,{children:e})};var io=a(70206),oo=a.n(io);const lo={...Z.N3,dynamicRenderType:"variable"},co=JSON.parse('{"cpu-time":"CPUTime","read-rows":"ReadRows","read-bytes":"ReadBytes","query-hash":"QueryHash","user":"User","start-time":"Start time","end-time":"End time","duration":"Duration","query-text":"Query text","application":"Application"}'),uo=(0,$e.g4)("ydb-top-queries-columns",{en:co}),mo="topQueriesColumnsWidth",po="CPUTime",ho="QueryText",vo="EndTime",go="ReadRows",yo="ReadBytes",xo="UserSID",bo="OneLineQueryText",fo="QueryHash",jo="Duration",So="QueryStartAt",To="ApplicationName",No={get CPUTime(){return uo("cpu-time")},get QueryText(){return uo("query-text")},get EndTime(){return uo("end-time")},get ReadRows(){return uo("read-rows")},get ReadBytes(){return uo("read-bytes")},get UserSID(){return uo("user")},get OneLineQueryText(){return uo("query-text")},get QueryHash(){return uo("query-hash")},get Duration(){return uo("duration")},get QueryStartAt(){return uo("start-time")},get ApplicationName(){return uo("application")}},Eo={CPUTime:"CPUTimeUs",QueryText:void 0,EndTime:"EndTime",ReadRows:"ReadRows",ReadBytes:"ReadBytes",UserSID:"UserSID",OneLineQueryText:void 0,QueryHash:void 0,Duration:"Duration",QueryStartAt:"QueryStartAt",ApplicationName:"ApplicationName"};function wo(e){return Eo[e]}function Co(e){return Boolean(wo(e))}const Po=(0,c.cn)("kv-top-queries"),Io={name:po,header:No.CPUTime,sortAccessor:e=>Number(e.CPUTimeUs),render:({row:e})=>{var t;return(0,vt.Xo)((0,vt.Jc)(null!==(t=e.CPUTimeUs)&&void 0!==t?t:void 0))},width:120,align:Rt.Ay.RIGHT,sortable:!1},Do={name:ho,header:No.QueryText,sortAccessor:e=>Number(e.CPUTimeUs),render:({row:e})=>{var t;return(0,d.jsx)("div",{className:Po("query"),children:(0,d.jsx)(so,{value:null===(t=e.QueryText)||void 0===t?void 0:t.toString(),maxQueryHeight:6})})},sortable:!1,width:500},Ao={name:vo,header:No.EndTime,render:({row:e})=>(0,he.r6)(new Date(e.EndTime).getTime()),align:Rt.Ay.RIGHT,width:200},_o={name:go,header:No.ReadRows,render:({row:e})=>(0,he.ZV)(e.ReadRows),sortAccessor:e=>Number(e.ReadRows),align:Rt.Ay.RIGHT,width:150},Ro={name:yo,header:No.ReadBytes,render:({row:e})=>(0,he.ZV)(e.ReadBytes),sortAccessor:e=>Number(e.ReadBytes),align:Rt.Ay.RIGHT,width:150},ko={name:xo,header:No.UserSID,render:({row:e})=>(0,d.jsx)("div",{className:Po("user-sid"),children:e.UserSID||"\u2013"}),sortAccessor:e=>String(e.UserSID),align:Rt.Ay.LEFT},Oo={name:bo,header:No.OneLineQueryText,render:({row:e})=>{var t;return(0,d.jsx)(hr,{children:(null===(t=e.QueryText)||void 0===t?void 0:t.toString())||""})},sortable:!1,width:500},Mo={name:fo,header:No.QueryHash,render:({row:e})=>{return t=String(e.QueryText),(oo().str(t)>>>0).toString(16).toUpperCase().padStart(8,"0");var t},width:130,sortable:!1},Lo={name:jo,header:No.Duration,render:({row:e})=>{var t;return(0,vt.Xo)((0,vt.Jc)(null!==(t=e.Duration)&&void 0!==t?t:void 0))},sortAccessor:e=>Number(e.Duration),align:Rt.Ay.RIGHT,width:150},zo={name:So,header:No.QueryStartAt,render:({row:e})=>(0,he.r6)(new Date(e.QueryStartAt).getTime()),sortable:!0,resizeable:!1,defaultOrder:Rt.Ay.DESCENDING},Fo={name:To,header:No.ApplicationName,render:({row:e})=>(0,d.jsx)("div",{className:Po("user-sid"),children:e.ApplicationName||"\u2013"}),sortable:!0};function qo({tenantName:e}){var t,a;const r=(0,X.YQ)(),s=(0,Xn.zy)(),i=(0,Xn.W6)(),o=(0,ye.mA)(s),[l]=(0,X.Nt)(),c=n.useMemo((()=>[Mo,Oo,Io].map((e=>({...e,sortable:!1})))),[]),{currentData:u,isFetching:m,error:p}=Di.Ke.useGetTopQueriesQuery({database:e},{pollingInterval:l}),h=m&&void 0===u,v=(null===u||void 0===u||null===(t=u.resultSets)||void 0===t||null===(a=t[0])||void 0===a?void 0:a.result)||[],g=no(n.useCallback((e=>{const{QueryText:t}=e;r((0,Ai.iZ)({input:t}));const a=(0,ye.mA)(s),n=(0,na.YL)({...a,[ae.Dt]:ae.Dg.query,[na.vh.queryTab]:ae.tQ.newQuery});i.push(n)}),[r,i,s])),y=Ci({entity:Es("queries"),postfix:Es("by-cpu-time",{executionPeriod:Es("executed-last-hour")}),onClick:()=>{r((0,Di.TX)({from:void 0,to:void 0}))},link:(0,na.YL)({...o,[na.vh.diagnosticsTab]:ae.iJ.topQueries})});return(0,d.jsx)(Ei,{columnsWidthLSKey:mo,data:v||[],columns:c,onRowClick:g,title:y,loading:h,error:(0,Nt.Cb)(p),rowClassName:()=>Ni("top-queries-row")})}function Qo(e,t){return`SELECT\n ${t?`CAST(SUBSTRING(CAST(Path AS String), ${t.length}) AS Utf8) AS Path`:"Path"},\n TabletId,\n CPUCores,\nFROM \`.sys/partition_stats\`\nWHERE\n Path='${e}'\n OR Path LIKE '${e}/%'\nORDER BY CPUCores DESC\nLIMIT ${Z.Nz}`}const Uo=H.F.injectEndpoints({endpoints:e=>({getTopShards:e.query({queryFn:async({database:e,path:t=""},{signal:a})=>{try{const n=await window.api.viewer.sendQuery({query:Qo(t,e),database:e,action:"execute-scan"},{signal:a,withRetries:!0});return(0,Nt.We)(n)?{error:n}:{data:(0,Nt.fW)(n)}}catch(n){return{error:n||new Error("Unauthorized")}}},providesTags:["All"]})}),overrideExisting:"throw"});var Bo=a(67884);function $o({path:e,location:t,...a}){const n=(0,ye.mA)(t),r=(0,ye.Ow)({...n,schema:e});return(0,d.jsx)(Bo.N,{view:"normal",...a,href:r})}var Ho=a(80420),Go=a(13342),Wo=a(16439),Vo=a(29819);const Jo=JSON.parse('{"tablet-id":"TabletId","cpu-cores":"CPUCores","data-size":"DataSize (B)","path":"Path","node-id":"NodeId","peak-time":"PeakTime","in-flight-tx-count":"InFlightTxCount","interval-end":"IntervalEnd"}'),Yo=(0,$e.g4)("ydb-top-shards-columns",{en:Jo}),Ko="topShardsColumnsWidth",Zo="TabletId",Xo="CPUCores",el="DataSize",tl="Path",al="NodeId",nl="PeakTime",rl="InFlightTxCount",sl="IntervalEnd",il={get TabletId(){return Yo("tablet-id")},get CPUCores(){return Yo("cpu-cores")},get DataSize(){return Yo("data-size")},get Path(){return Yo("path")},get NodeId(){return Yo("node-id")},get PeakTime(){return Yo("peak-time")},get InFlightTxCount(){return Yo("in-flight-tx-count")},get IntervalEnd(){return Yo("interval-end")}},ol={TabletId:void 0,CPUCores:"CPUCores",DataSize:"DataSize",Path:void 0,NodeId:void 0,PeakTime:void 0,InFlightTxCount:"InFlightTxCount",IntervalEnd:void 0};function ll(e){return ol[e]}const cl=(e,t)=>({name:tl,header:il.Path,render:({row:a})=>(0,d.jsx)($o,{path:e+a.Path,location:t,children:a.Path}),sortable:!1,width:300}),dl={name:Xo,header:il.CPUCores,render:({row:e})=>{return t=e.CPUCores||0,`${(0,he.CR)(100*Number(t),2)}%`;var t},align:Rt.Ay.RIGHT},ul={name:el,header:il.DataSize,render:({row:e})=>(0,he.ZV)(e.DataSize),align:Rt.Ay.RIGHT},ml={name:Zo,header:il.TabletId,render:({row:e})=>e.TabletId?(0,d.jsx)(Ho.$,{tabletId:e.TabletId}):"\u2013",sortable:!1,width:220},pl={name:al,header:il.NodeId,render:({row:e})=>e.NodeId?(0,d.jsx)(Aa.E,{to:(0,Vo.vI)(e.NodeId),children:e.NodeId}):"\u2013",align:Rt.Ay.RIGHT},hl={name:Xo,header:il.CPUCores,render:({row:e})=>(0,d.jsx)(Go.U,{value:(0,he.CR)(100*Number(e.CPUCores),2),theme:(0,Wo.f)(100*Number(e.CPUCores))}),align:Rt.Ay.RIGHT,sortable:!1,width:140,resizeMinWidth:140},vl={name:rl,header:il.InFlightTxCount,render:({row:e})=>(0,he.ZV)(e.InFlightTxCount),align:Rt.Ay.RIGHT},gl=({tenantName:e,path:t})=>{var a,n;const r=(0,Xn.zy)(),s=(0,ye.mA)(r),[i]=(0,X.Nt)(),{currentData:o,isFetching:l,error:c}=Uo.useGetTopShardsQuery({database:e,path:t},{pollingInterval:i}),u=l&&void 0===o,m=(null===o||void 0===o||null===(a=o.resultSets)||void 0===a||null===(n=a[0])||void 0===n?void 0:n.result)||[],p=((e,t)=>[ml,cl(e,t),hl])(e,r),h=Ci({entity:Es("shards"),postfix:Es("by-cpu-usage"),link:(0,na.YL)({...s,[na.vh.diagnosticsTab]:ae.iJ.topShards})});return(0,d.jsx)(Ei,{columnsWidthLSKey:Ko,data:m||[],columns:p,title:h,loading:u,error:(0,Nt.Cb)(c)})},yl=[{title:Es("charts.cpu-usage"),metrics:["IC","IO","Batch","User","System"].map((e=>({target:`resources.cpu.${e}.usage`,title:e}))),options:{dataType:"percent",scaleRange:{min:0,max:1},showLegend:!0}}];function xl({tenantName:e,additionalNodesProps:t}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Ts,{database:e,charts:yl}),(0,d.jsx)(Ii,{tenantName:e,additionalNodesProps:t}),(0,d.jsx)(Pi,{tenantName:e,additionalNodesProps:t}),(0,d.jsx)(gl,{tenantName:e,path:e}),(0,d.jsx)(qo,{tenantName:e})]})}var bl=a(73473);function fl({tenantName:e,additionalNodesProps:t}){const a=(0,X.e4)(),[n]=(0,X.Nt)(),[r,s]=function(e){const t=[(0,fi._E)(),(0,fi.Nh)(e),(0,fi.jl)(),(0,fi.fR)(),(0,fi.iX)(),(0,fi.oz)(),(0,fi.qp)(e)].map((e=>({...e,sortable:!1}))),a=t.map((e=>e.name));return[t,(0,Ti.R)(a,ji.fN)]}({getNodeRef:null===t||void 0===t?void 0:t.getNodeRef,database:e}),{currentData:i,isFetching:o,error:l}=Si.s.useGetNodesQuery({tenant:e,type:"any",tablets:!0,sort:"-Memory",limit:Z.Nz,fieldsRequired:s},{pollingInterval:n}),c=o&&void 0===i,u=(null===i||void 0===i?void 0:i.Nodes)||[],m=Ci({entity:Es("nodes"),postfix:Es("by-memory"),link:(0,na.YL)({...a,[na.vh.diagnosticsTab]:ae.iJ.nodes})});return(0,d.jsx)(Ei,{columnsWidthLSKey:ji.zO,data:u,columns:r,title:m,loading:c,error:l,emptyDataMessage:Es("top-nodes.empty-data")})}const jl=[{title:Es("charts.memory-usage"),metrics:[{target:"resources.memory.used_bytes",title:Es("charts.memory-usage")}],options:{dataType:"size"}}];function Sl({tenantName:e,memoryStats:t,memoryUsed:a,memoryLimit:r}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Ts,{database:e,charts:jl}),(0,d.jsx)("div",{className:Ni("title"),children:"Memory details"}),(0,d.jsx)("div",{className:Ni("memory-info"),children:t?(0,d.jsx)(bl.S,{formatValues:he.vX,stats:t}):(0,d.jsx)(di.O,{value:a,capacity:r,formatValues:he.vX,colorizeProgress:!0})}),(0,d.jsx)(fl,{tenantName:e})]})}var Tl=a(18863),Nl=a(10174),El=a(20831),wl=a(10360);function Cl({tenant:e}){const t=(0,X.e4)(),a=(0,ie.Pm)(),n=(0,ie.YA)(),[r]=(0,X.Nt)(),[s,i]=function(){const e=(0,El.k)(),t=e.map((e=>e.name));return[e,(0,Ti.R)(t,wl.YX)]}(),{currentData:o,isFetching:l,error:c}=Nl.S.useGetStorageGroupsInfoQuery({tenant:e,sort:"-Usage",with:"all",limit:Z.Nz,shouldUseGroupsHandler:n,fieldsRequired:i},{pollingInterval:r,skip:!a}),u=l&&void 0===o,m=(null===o||void 0===o?void 0:o.groups)||[],p=Ci({entity:Es("groups"),postfix:Es("by-usage"),link:(0,na.YL)({...t,[na.vh.diagnosticsTab]:ae.iJ.storage})});return(0,d.jsx)(Ei,{columnsWidthLSKey:wl.qK,data:m,columns:s,title:p,loading:u||!a,error:c})}const Pl=e=>`\nSELECT\n Path, SUM(DataSize) as Size\nFROM \`${e}/.sys/partition_stats\`\nGROUP BY Path\n ORDER BY Size DESC\n LIMIT ${Z.Nz}\n`,Il=H.F.injectEndpoints({endpoints:e=>({getTopTables:e.query({queryFn:async({path:e},{signal:t})=>{try{const a=await window.api.viewer.sendQuery({query:Pl(e),database:e,action:"execute-scan"},{signal:t,withRetries:!0});return(0,Nt.We)(a)?{error:a}:{data:(0,Nt.fW)(a)}}catch(a){return{error:a||"Unauthorized"}}},providesTags:["All"]})}),overrideExisting:"throw"});function Dl({path:e}){var t,a;const n=(0,Xn.zy)(),[r]=(0,X.Nt)(),{currentData:s,error:i,isFetching:o}=Il.useGetTopTablesQuery({path:e},{pollingInterval:r}),l=o&&void 0===s,c=(null===s||void 0===s||null===(t=s.resultSets)||void 0===t||null===(a=t[0])||void 0===a?void 0:a.result)||[],u=[{name:"Size",width:100,sortable:!1,render:({row:e})=>(e=>{const t=(0,ha.dd)(null!==c&&void 0!==c&&c.length?Number(c[0].Size):0,0);return(0,ha.z3)({value:e,size:t,precision:1})})(Number(e.Size)),align:Rt.Ay.RIGHT},{name:"Path",width:700,sortable:!1,render:({row:e})=>e.Path?(0,d.jsx)(ut.s,{content:e.Path,children:(0,d.jsx)($o,{path:String(e.Path),location:n,children:e.Path})}):null}],m=Ci({entity:Es("tables"),postfix:Es("by-size")});return(0,d.jsx)(Ei,{columnsWidthLSKey:"topTablesTableColumnsWidth",data:c||[],columns:u,title:m,loading:l,error:(0,Nt.Cb)(i)})}const Al=[{title:Es("charts.storage-usage"),metrics:[{target:"resources.storage.used_bytes",title:Es("charts.storage-usage")}],options:{dataType:"size"}}];function _l({tenantName:e,metrics:t}){const{blobStorageUsed:a,tabletStorageUsed:r,blobStorageLimit:s,tabletStorageLimit:i}=t,o=[{label:(0,d.jsx)(Ra,{text:Es("storage.tablet-storage-title"),popoverContent:Es("storage.tablet-storage-description")}),value:(0,d.jsx)(di.O,{value:r,capacity:i,formatValues:he.j9,colorizeProgress:!0})},{label:(0,d.jsx)(Ra,{text:Es("storage.db-storage-title"),popoverContent:Es("storage.db-storage-description")}),value:(0,d.jsx)(di.O,{value:a,capacity:s,formatValues:he.j9,colorizeProgress:!0})}];return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Ts,{database:e,charts:Al}),(0,d.jsx)(Tl.z,{className:Ni("storage-info"),title:"Storage details",info:o}),(0,d.jsx)(Dl,{path:e}),(0,d.jsx)(Cl,{tenant:e})]})}function Rl({tenantName:e,additionalTenantProps:t,additionalNodesProps:a}){var n,r,s;const{metricsTab:i}=(0,X.N4)((e=>e.tenant)),[o]=(0,X.Nt)(),{currentData:l,isFetching:c}=oe.z6.useGetTenantInfoQuery({path:e},{pollingInterval:o}),u=c&&void 0===l,{Name:m,Type:p,Overall:h}=l||{},v=(g=p)&&P[g];var g;const{currentData:y}=G.useGetOverviewQuery({path:e,database:e},{pollingInterval:o}),{Tables:x,Topics:b}=(null===y||void 0===y||null===(n=y.PathDescription)||void 0===n||null===(r=n.DomainDescription)||void 0===r?void 0:r.DiskSpaceUsage)||{},f=[null===x||void 0===x?void 0:x.TotalSize,null===b||void 0===b?void 0:b.DataSize].reduce(((e,t)=>t?e+Number(t):e),0),j={...l,Metrics:{...null===l||void 0===l?void 0:l.Metrics,Storage:String(f)}},{blobStorage:S,tabletStorage:T,blobStorageLimit:N,tabletStorageLimit:E,poolsStats:w,memoryStats:C,blobStorageStats:I,tabletStorageStats:D}=(0,as.uI)(j),A={blobStorageUsed:S,blobStorageLimit:N,tabletStorageUsed:T,tabletStorageLimit:E};if(u)return(0,d.jsx)("div",{className:Ni("loader"),children:(0,d.jsx)(Zr.a,{size:"m"})});const _=null===t||void 0===t||null===(s=t.getMonitoringLink)||void 0===s?void 0:s.call(t,m,p);return(0,d.jsxs)("div",{className:Ni(),children:[(0,d.jsxs)("div",{className:Ni("info"),children:[(0,d.jsx)("div",{className:Ni("top-label"),children:v}),(0,d.jsxs)("div",{className:Ni("top"),children:[(0,d.jsx)("div",{className:Ni("tenant-name-wrapper"),children:(0,d.jsx)(Hn.c,{status:h,name:m||Z.oK,withLeftTrim:!0,hasClipboardButton:Boolean(l),clipboardButtonAlwaysVisible:!0})}),_&&(0,d.jsx)(ts,{href:_})]}),(0,d.jsx)(gi,{poolsCpuStats:w,memoryStats:C,blobStorageStats:I,tabletStorageStats:D,tenantName:e})]}),(()=>{switch(i){case ae.pA.cpu:return(0,d.jsx)(xl,{tenantName:e,additionalNodesProps:a});case ae.pA.storage:return(0,d.jsx)(_l,{tenantName:e,metrics:A});case ae.pA.memory:return(0,d.jsx)(Sl,{tenantName:e,memoryUsed:j.MemoryUsed,memoryLimit:j.MemoryLimit,memoryStats:j.MemoryStats});case ae.pA.healthcheck:return(0,d.jsx)(Zs,{tenantName:e});default:return(0,d.jsx)(Cs,{database:e})}})()]})}const kl=(0,c.cn)("kv-detailed-overview");const Ol=function(e){const{type:t,tenantName:a,path:n,additionalTenantProps:r,additionalNodesProps:s}=e,i=a===n;return(0,d.jsx)("div",{className:kl(),children:i?(0,d.jsx)("div",{className:kl("section"),children:(0,d.jsx)(Rl,{tenantName:a,additionalTenantProps:r,additionalNodesProps:s})}):(0,d.jsx)(Yr,{type:t,path:n,database:a})})},Ml={id:ae.iJ.overview,title:"Info"},Ll={id:ae.iJ.schema,title:"Schema"},zl={id:ae.iJ.topQueries,title:"Queries"},Fl={id:ae.iJ.topShards,title:"Top shards"},ql={id:ae.iJ.nodes,title:"Nodes"},Ql={id:ae.iJ.tablets,title:"Tablets"},Ul={id:ae.iJ.storage,title:"Storage"},Bl={id:ae.iJ.network,title:"Network"},$l={id:ae.iJ.describe,title:"Describe"},Hl={id:ae.iJ.hotKeys,title:"Hot keys"},Gl={id:ae.iJ.graph,title:"Graph"},Wl={id:ae.iJ.consumers,title:"Consumers"},Vl={id:ae.iJ.partitions,title:"Partitions"},Jl=[Ml,Ql,$l],Yl=[Ml,zl,Fl,ql,Ql,Ul,Bl,$l,{id:ae.iJ.configs,title:"Configs"},{id:ae.iJ.operations,title:"Operations"}],Kl=[Ml,Ll,Fl,ql,Gl,Ql,Hl,$l],Zl=[Ml,Ll,Fl,ql,Ql,$l],Xl=[Ml,Fl,ql,$l],ec=[Ml,Wl,Vl,ql,Ql,$l],tc=[Ml,Wl,Vl,ql,Ql,$l],ac=[Ml,$l],nc=[Ml,Ll,$l],rc=[Ml,Ll,$l],sc={[x.EPathTypeInvalid]:void 0,[x.EPathTypeSubDomain]:Yl,[x.EPathTypeExtSubDomain]:Yl,[x.EPathTypeColumnStore]:Yl,[x.EPathTypeTable]:Kl,[x.EPathTypeColumnTable]:Zl,[x.EPathTypeDir]:Xl,[x.EPathTypeTableIndex]:Xl,[x.EPathTypeCdcStream]:ec,[x.EPathTypePersQueueGroup]:tc,[x.EPathTypeExternalDataSource]:ac,[x.EPathTypeExternalTable]:nc,[x.EPathTypeView]:rc,[x.EPathTypeReplication]:Jl};var ic=a(81240),oc=a(80604);const lc=H.F.injectEndpoints({endpoints:e=>({getHotKeys:e.query({queryFn:async({path:e,database:t},{signal:a})=>{try{var n;const r=await window.api.viewer.getHotKeys({path:e,database:t,enableSampling:!0},{signal:a});if(Array.isArray(r.hotkeys))return{data:r.hotkeys};await Promise.race([new Promise((e=>{setTimeout(e,5e3)})),new Promise(((e,t)=>{a.addEventListener("abort",t)}))]);return{data:null!==(n=(await window.api.viewer.getHotKeys({path:e,database:t,enableSampling:!1},{signal:a})).hotkeys)&&void 0!==n?n:null}}catch(r){return{error:r}}},providesTags:["All"]})}),overrideExisting:"throw"}),cc=JSON.parse('{"hot-keys-collecting":"Please wait a little while we are collecting hot keys samples...","no-data":"No information about hot keys","help":"Hot keys contains a list of table primary key values that are accessed most often. Sample is collected upon request to the tab during 5s time interval. Samples column indicates how many requests to the particular key value were registered during collection phase."}'),dc=(0,$e.g4)("ydb-hot-keys",{en:cc});var uc;function mc(){return mc=Object.assign?Object.assign.bind():function(e){for(var t=1;t((e=[])=>[...e.map(((e,t)=>({name:e,header:(0,d.jsxs)("div",{className:hc("primary-key-column"),children:[(0,d.jsx)(ct.I,{data:pc,width:12,height:7}),e]}),render:({row:e})=>e.keyValues[t],align:Rt.Ay.RIGHT,sortable:!1}))),{name:vc,header:"Samples",render:({row:e})=>e.accessSample,align:Rt.Ay.RIGHT,sortable:!1}])(p)),[p]);return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(yc,{}),l||m?(0,d.jsx)("div",{children:dc("hot-keys-collecting")}):o?(0,d.jsx)(de.o,{error:o}):s?(0,d.jsx)(Fe.l,{wrapperClassName:hc("table"),columns:h,data:s,settings:Z.N3,initialSortOrder:{columnId:vc,order:Rt.Ay.DESCENDING}}):(0,d.jsx)("div",{children:dc("no-data")})]})}function yc(){const[e,t]=(0,X.iK)(Z.Gj);return e?null:(0,d.jsxs)(oc.Z,{theme:"info",view:"filled",type:"container",className:hc("help-card"),children:[dc("help"),(0,d.jsx)(hn.$,{className:hc("help-card__close-button"),view:"flat",onClick:()=>t(!0),children:(0,d.jsx)(ct.I,{data:ic.A,size:18})})]})}var xc=a(78524),bc=a(9252);const fc=H.F.injectEndpoints({endpoints:e=>({getNetworkInfo:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await window.api.viewer.getNetwork({path:e,database:e},{signal:t})}}catch(a){return{error:a}}},providesTags:["All"]})}),overrideExisting:"throw"});var jc=a(88610);const Sc=(0,c.cn)("node-network");function Tc(){}function Nc({nodeId:e,connected:t,capacity:a,rack:r,status:s,onClick:i=Tc,onMouseEnter:o=Tc,onMouseLeave:l=Tc,showID:c,isBlurred:u}){const m=n.useRef(null),p=s||function(e=0,t=0){const a=Math.floor(e/t*100);return 100===a?Us.m.Green:a>=70?Us.m.Yellow:a>=1?Us.m.Red:Us.m.Grey}(t,a);return(0,d.jsx)("div",{ref:m,className:Sc({[p.toLowerCase()]:!0,id:c,blur:u}),onMouseEnter:()=>{o(m.current,{nodeId:e,connected:t,capacity:a,rack:r},"node")},onMouseLeave:()=>{l()},onClick:()=>i(e),children:c?e:null})}const Ec=e=>null===e||void 0===e?void 0:e.reduce(((e,t)=>t.Connected?e+1:e),0);var wc,Cc,Pc,Ic,Dc,Ac,_c,Rc,kc,Oc,Mc,Lc,zc,Fc,qc;function Qc(){return Qc=Object.assign?Object.assign.bind():function(e){for(var t=1;t0?(0,d.jsx)("div",{className:Bc("inner"),children:(0,d.jsxs)("div",{className:Bc("nodes-row"),children:[(0,d.jsxs)("div",{className:Bc("left"),children:[(0,d.jsx)("div",{className:Bc("controls-wrapper"),children:(0,d.jsxs)("div",{className:Bc("controls"),children:[(0,d.jsx)(bc.k,{value:s,onChange:e=>{i((0,jc.$u)(e))},className:Bc("problem-filter")}),(0,d.jsx)("div",{className:Bc("checkbox-wrapper"),children:(0,d.jsx)(ce.S,{onUpdate:()=>{u(!c)},checked:c,children:"ID"})}),(0,d.jsx)("div",{className:Bc("checkbox-wrapper"),children:(0,d.jsx)(ce.S,{onUpdate:()=>{p(!m)},checked:m,children:"Racks"})})]})}),(0,d.jsx)(Hc,{nodes:b,showId:c,showRacks:m,clickedNode:o,onClickNode:l})]}),(0,d.jsx)("div",{className:Bc("right"),children:o?(0,d.jsxs)("div",{children:[(0,d.jsxs)("div",{className:Bc("label"),children:["Connectivity of node"," ",(0,d.jsx)(re.N_,{className:Bc("link"),to:(0,Vo.vI)(o.NodeId),children:o.NodeId})," ","to other nodes"]}),(0,d.jsx)("div",{className:Bc("nodes-row"),children:(0,d.jsx)(Hc,{nodes:f,isRight:!0,showId:c,showRacks:m,clickedNode:o,onClickNode:l})})]}):(0,d.jsxs)("div",{className:Bc("placeholder"),children:[(0,d.jsx)("div",{className:Bc("placeholder-img"),children:(0,d.jsx)(ct.I,{data:Uc,width:221,height:204})}),(0,d.jsx)("div",{className:Bc("placeholder-text"),children:"Select node to see its connectivity to other nodes"})]})})]})}):null]})}function Hc({nodes:e,isRight:t,showId:a,showRacks:n,clickedNode:r,onClickNode:s}){const i=(0,X.N4)(jc.yV),o=(0,X.YQ)();let l=0;const c=Object.keys(e).map(((c,u)=>{const m=Gc(e[c],"Rack");return(0,d.jsxs)("div",{className:Bc("nodes-container",{right:t}),children:[(0,d.jsxs)("div",{className:Bc("nodes-title"),children:[c," nodes"]}),(0,d.jsx)("div",{className:Bc("nodes"),children:n?Object.keys(m).map(((e,n)=>(0,d.jsxs)("div",{className:Bc("rack-column"),children:[(0,d.jsx)("div",{className:Bc("rack-index"),children:"undefined"===e?"?":e}),m[e].map(((e,n)=>{let c,u;return!t&&"Peers"in e&&e.Peers&&(c=Object.keys(e.Peers).length,u=Ec(e.Peers)),i===jc.s$.PROBLEMS&&c!==u||i===jc.s$.ALL||t?(l++,(0,d.jsx)(Nc,{nodeId:e.NodeId,showID:a,rack:e.Rack,status:"ConnectStatus"in e?e.ConnectStatus:void 0,capacity:c,connected:u,onMouseEnter:(...e)=>{o((0,pe.DK)(...e))},onMouseLeave:()=>{o((0,pe.w7)())},onClick:t?void 0:()=>{s(r&&e.NodeId===r.NodeId?void 0:e)},isBlurred:!t&&r&&r.NodeId!==e.NodeId},n)):null}))]},n))):e[c].map(((e,n)=>{let c,u;const m=e&&"Peers"in e?e.Peers:void 0;return!t&&"Peers"in e&&e.Peers&&(c=e.Peers.length,u=Ec(m)),i===jc.s$.PROBLEMS&&c!==u||i===jc.s$.ALL||t?(l++,(0,d.jsx)(Nc,{nodeId:e.NodeId,showID:a,rack:e.Rack,status:"ConnectStatus"in e?e.ConnectStatus:void 0,capacity:null===m||void 0===m?void 0:m.length,connected:u,onMouseEnter:(...e)=>{o((0,pe.DK)(...e))},onMouseLeave:()=>{o((0,pe.w7)())},onClick:t?void 0:()=>{s(r&&e.NodeId===r.NodeId?void 0:e)},isBlurred:!t&&r&&r.NodeId!==e.NodeId},n)):null}))})]},u)}));return i===jc.s$.PROBLEMS&&0===l?(0,d.jsx)(xc.v,{name:"thumbsUp",width:"200"}):c}function Gc(e,t){return e.reduce(((e,a)=>(e[a[t]]?e[a[t]].push(a):e[a[t]]=[a],e)),{})}const Wc=["NodeId","Host","Connections","NetworkUtilization","SendThroughput","ReceiveThroughput","PingTime","ClockSkew"],Vc=["NodeId"],Jc=["Host","DC","Rack","Uptime","ConnectStatus","NetworkUtilization","PingTime","ClockSkew"];function Yc({database:e,path:t,parentRef:a,additionalNodesProps:n}){const r=(0,ie.Pm)(),s=(0,ie.WF)(),[i]=(0,X.iK)(Z.g5),l=s&&i;return(0,d.jsx)(o.r,{loading:!r,children:(()=>{return l?(0,d.jsx)(Le.G,{path:t,database:e,parentRef:a,withPeerRoleFilter:!0,additionalNodesProps:n,columns:(r={database:e,getNodeRef:null===n||void 0===n?void 0:n.getNodeRef},[(0,fi._E)(),(0,fi.Nh)(r,{statusForIcon:"ConnectStatus"}),(0,fi.uk)(),(0,fi.OX)(),(0,fi.jl)(),(0,fi.fr)(),(0,fi.kv)(),(0,fi.SH)(),(0,fi.H)(),(0,fi.DH)(),(0,fi.ui)(),(0,fi.wN)(),(0,fi.pt)()].map((e=>({...e,sortable:(0,ji.sp)(e.name)})))),defaultColumnsIds:Wc,requiredColumnsIds:Vc,selectedColumnsKey:"networkNodesTableSelectedColumns",groupByParams:Jc}):(0,d.jsx)($c,{tenantName:e});var r})()})}var Kc=a(24600),Zc=a(47058),Xc=a(69775),ed=a(41775);const td=JSON.parse('{"lagsPopover.writeLags":"Write lags statistics (time format dd hh:mm:ss)","lagsPopover.readLags":"Read lags statistics (time format dd hh:mm:ss)","headers.unread":"End offset - Last read offset","headers.uncommited":"End offset - Committed offset","controls.consumerSelector":"Consumer:","controls.consumerSelector.emptyOption":"No consumer","controls.partitionSearch":"Partition ID","controls.generalSearch":"Host, Host ID, Reader, Read Session ID","table.emptyDataMessage":"No partitions match the current search","noConsumersMessage.topic":"This topic has no consumers","noConsumersMessage.stream":"This changefeed has no consumers"}'),ad=JSON.parse('{"lagsPopover.writeLags":"\u0421\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0430 \u043b\u0430\u0433\u043e\u0432 \u0437\u0430\u043f\u0438\u0441\u0438 (\u0444\u043e\u0440\u043c\u0430\u0442 \u0432\u0440\u0435\u043c\u0435\u043d\u0438 \u0434\u0434 \u0447\u0447:\u043c\u043c:\u0441\u0441)","lagsPopover.readLags":"\u0421\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0430 \u043b\u0430\u0433\u043e\u0432 \u0447\u0442\u0435\u043d\u0438\u044f (\u0444\u043e\u0440\u043c\u0430\u0442 \u0432\u0440\u0435\u043c\u0435\u043d\u0438 \u0434\u0434 \u0447\u0447:\u043c\u043c:\u0441\u0441)","headers.unread":"End offset - Last read offset","headers.uncommited":"End offset - Committed offset","controls.consumerSelector":"\u0427\u0438\u0442\u0430\u0442\u0435\u043b\u044c:","controls.consumerSelector.emptyOption":"\u041d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u044f","controls.partitionSearch":"Partition ID","controls.generalSearch":"Host, Host ID, Reader, Read Session ID","table.emptyDataMessage":"\u041f\u043e \u0437\u0430\u0434\u0430\u043d\u043d\u043e\u043c\u0443 \u043f\u043e\u0438\u0441\u043a\u0443 \u043d\u0435\u0442 \u043f\u0430\u0440\u0442\u0438\u0446\u0438\u0439","noConsumersMessage.topic":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0442\u043e\u043f\u0438\u043a\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439","noConsumersMessage.stream":"\u0423 \u044d\u0442\u043e\u0433\u043e \u0441\u0442\u0440\u0438\u043c\u0430 \u043d\u0435\u0442 \u0447\u0438\u0442\u0430\u0442\u0435\u043b\u0435\u0439"}'),nd=(0,$e.g4)("ydb-diagnostics-partitions",{ru:ad,en:td}),rd={PARTITION_ID:"partitionId",STORE_SIZE:"storeSize",WRITE_SPEED:"writeSpeed",READ_SPEED:"readSpeed",WRITE_LAGS:"writeLags",READ_LAGS:"readLags",UNCOMMITED_MESSAGES:"uncommitedMessages",UNREAD_MESSAGES:"unreadMessages",START_OFFSET:"startOffset",END_OFFSET:"endOffset",COMMITED_OFFSET:"commitedOffset",READ_SESSION_ID:"readSessionId",READER_NAME:"readerName",PARTITION_HOST:"partitionHost",CONNECTION_HOST:"connectionHost"},sd={[rd.PARTITION_ID]:"Partition ID",[rd.STORE_SIZE]:"Store size",[rd.WRITE_SPEED]:"Write speed",[rd.READ_SPEED]:"Read speed",[rd.WRITE_LAGS]:"Write lags, duration",[rd.READ_LAGS]:"Read lags, duration",[rd.UNCOMMITED_MESSAGES]:"Uncommited messages",[rd.UNREAD_MESSAGES]:"Unread messages",[rd.START_OFFSET]:"Start offset",[rd.END_OFFSET]:"End offset",[rd.COMMITED_OFFSET]:"Commited offset",[rd.READ_SESSION_ID]:"Read session ID",[rd.READER_NAME]:"Reader name",[rd.PARTITION_HOST]:"Partition host",[rd.CONNECTION_HOST]:"Connection host"},id="partitionWriteLag",od="partitionWriteIdleTime",ld={[id]:"write lag",[od]:"write idle time"},cd="consumerWriteLag",dd="consumerReadLag",ud="consumerReadIdleTime",md={[cd]:"write lag",[dd]:"read lag",[ud]:"read idle time"},pd=[rd.PARTITION_ID,rd.STORE_SIZE,rd.WRITE_SPEED,rd.WRITE_LAGS,rd.START_OFFSET,rd.END_OFFSET,rd.PARTITION_HOST],hd=Object.values(rd),vd=({consumers:e,selectedConsumer:t,onSelectedConsumerChange:a,selectDisabled:r,partitions:s,onSearchChange:i,hiddenColumns:o,onHiddenColumnsChange:l,initialColumnsIds:c})=>{const[u,m]=n.useState(""),[p,h]=n.useState("");n.useEffect((()=>{if(!s)return;const e=new RegExp(pa()(p),"i"),t=new RegExp(pa()(u),"i"),a=s.filter((a=>{const{partitionId:n,readerName:r,readSessionId:s,partitionNodeId:i,connectionNodeId:o,partitionHost:l,connectionHost:c}=a,d=e.test(n),u=[r,s,i,o,l,c].filter(Boolean).map(String),m=0===u.length||u.some((e=>t.test(e)));return d&&m}));i(a)}),[p,u,s,i]);const v=n.useMemo((()=>{const t=e&&e.length?e.map((e=>({value:e,content:e}))):[];return[{value:"",content:nd("controls.consumerSelector.emptyOption")},...t]}),[e]),g=n.useMemo((()=>{const e=[];for(const t of c){const a=t===rd.PARTITION_ID,n={title:sd[t],selected:Boolean(!o.includes(t)),id:t,required:a,sticky:a?"start":void 0};a?e.unshift(n):e.push(n)}return e}),[c,o]),y=e=>(0,d.jsx)("div",{className:wd("select-option",{empty:""===e.value}),children:e.content});return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(le.l,{className:wd("consumer-select"),label:nd("controls.consumerSelector"),options:v,value:[t||""],onUpdate:e=>{a(e[0]||void 0)},filterable:e&&e.length>5,disabled:r||!e||!e.length,renderOption:y,renderSelectedOption:y}),(0,d.jsx)(ed.v,{onChange:e=>{h(e)},placeholder:nd("controls.partitionSearch"),className:wd("search",{partition:!0}),value:p}),(0,d.jsx)(ed.v,{onChange:e=>{m(e)},placeholder:nd("controls.generalSearch"),className:wd("search",{general:!0}),value:u}),(0,d.jsx)(Xc.O,{popupWidth:242,items:g,showStatus:!0,onUpdate:e=>{const t=[...o];e.forEach((e=>{e.selected||o.includes(e.id)?e.selected&&o.includes(e.id)&&t.splice(o.indexOf(e.id)):t.push(e.id)})),l(t)},sortable:!1},"TableColumnSetup")]})},gd=(0,c.cn)("ydb-diagnostics-partitions-columns-header"),yd=({title:e})=>(0,d.jsx)("div",{className:gd("multiline"),children:e}),xd=()=>(0,d.jsx)("div",{className:gd("read-session"),children:sd[rd.READ_SESSION_ID]}),bd=()=>(0,d.jsx)(Ra,{className:gd("lags"),text:sd[rd.WRITE_LAGS],popoverContent:(0,d.jsx)(Wa,{text:nd("lagsPopover.writeLags"),type:"write"})}),fd=()=>(0,d.jsx)(Ra,{className:gd("lags"),text:sd[rd.READ_LAGS],popoverContent:(0,d.jsx)(Wa,{text:nd("lagsPopover.readLags"),type:"read"})}),jd=()=>(0,d.jsx)(Ra,{className:gd("messages"),text:sd[rd.UNREAD_MESSAGES],popoverContent:(0,d.jsx)("div",{className:gd("messages-popover-content"),children:nd("headers.unread")})}),Sd=()=>(0,d.jsx)(Ra,{className:gd("messages"),text:sd[rd.UNCOMMITED_MESSAGES],popoverContent:(0,d.jsx)("div",{className:gd("messages-popover-content"),children:nd("headers.uncommited")})}),Td=(0,c.cn)("ydb-diagnostics-partitions-columns"),Nd=[{name:rd.PARTITION_ID,header:(0,d.jsx)(yd,{title:sd[rd.PARTITION_ID]}),sortAccessor:e=>(0,$r.kf)(e.partitionId)&&Number(e.partitionId),align:Rt.Ay.LEFT,render:({row:e})=>e.partitionId},{name:rd.STORE_SIZE,header:(0,d.jsx)(yd,{title:sd[rd.STORE_SIZE]}),align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.z3)(e.storeSize)},{name:rd.WRITE_SPEED,header:sd[rd.WRITE_SPEED],align:Rt.Ay.LEFT,resizeMinWidth:140,sortAccessor:e=>e.writeSpeed.perMinute,render:({row:e})=>(0,d.jsx)(wa,{data:e.writeSpeed})},{name:rd.READ_SPEED,header:sd[rd.READ_SPEED],align:Rt.Ay.LEFT,resizeMinWidth:140,sortAccessor:e=>{var t;return null===(t=e.readSpeed)||void 0===t?void 0:t.perMinute},render:({row:e})=>(0,d.jsx)(wa,{data:e.readSpeed})},{name:rd.WRITE_LAGS,header:(0,d.jsx)(bd,{}),className:Td("lags-header"),sub:[{name:id,header:ld[id],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.partitionWriteLag)},{name:od,header:ld[od],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.partitionWriteIdleTime)}]},{name:rd.READ_LAGS,header:(0,d.jsx)(fd,{}),className:Td("lags-header"),sub:[{name:cd,header:md[cd],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.consumerWriteLag)},{name:dd,header:md[dd],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.consumerReadLag)},{name:ud,header:md[ud],align:Rt.Ay.RIGHT,render:({row:e})=>(0,he.lr)(e.consumerReadIdleTime)}]},{name:rd.UNCOMMITED_MESSAGES,header:(0,d.jsx)(Sd,{}),align:Rt.Ay.RIGHT,render:({row:e})=>e.uncommitedMessages},{name:rd.UNREAD_MESSAGES,header:(0,d.jsx)(jd,{}),align:Rt.Ay.RIGHT,render:({row:e})=>e.unreadMessages},{name:rd.START_OFFSET,header:(0,d.jsx)(yd,{title:sd[rd.START_OFFSET]}),sortAccessor:e=>(0,$r.kf)(e.startOffset)&&Number(e.startOffset),align:Rt.Ay.RIGHT,render:({row:e})=>e.startOffset},{name:rd.END_OFFSET,header:(0,d.jsx)(yd,{title:sd[rd.END_OFFSET]}),sortAccessor:e=>(0,$r.kf)(e.endOffset)&&Number(e.endOffset),align:Rt.Ay.RIGHT,render:({row:e})=>e.endOffset},{name:rd.COMMITED_OFFSET,header:(0,d.jsx)(yd,{title:sd[rd.COMMITED_OFFSET]}),sortAccessor:e=>(0,$r.kf)(e.commitedOffset)&&Number(e.commitedOffset),align:Rt.Ay.RIGHT,render:({row:e})=>e.commitedOffset},{name:rd.READ_SESSION_ID,header:(0,d.jsx)(xd,{}),align:Rt.Ay.LEFT,width:150,render:({row:e})=>e.readSessionId?(0,d.jsx)(Hn.c,{name:e.readSessionId,showStatus:!1,hasClipboardButton:!0}):"\u2013"},{name:rd.READER_NAME,header:(0,d.jsx)(yd,{title:sd[rd.READER_NAME]}),align:Rt.Ay.LEFT,width:150,render:({row:e})=>e.readerName?(0,d.jsx)(Hn.c,{name:e.readerName,showStatus:!1,hasClipboardButton:!0}):"\u2013"},{name:rd.PARTITION_HOST,header:(0,d.jsx)(yd,{title:sd[rd.PARTITION_HOST]}),align:Rt.Ay.LEFT,width:200,render:({row:e})=>e.partitionNodeId&&e.partitionHost?(0,d.jsx)(Hn.c,{name:e.partitionHost,path:(0,Vo.vI)(e.partitionNodeId),showStatus:!1,hasClipboardButton:!0}):"\u2013"},{name:rd.CONNECTION_HOST,header:(0,d.jsx)(yd,{title:sd[rd.CONNECTION_HOST]}),align:Rt.Ay.LEFT,width:200,render:({row:e})=>e.connectionNodeId&&e.connectionHost?(0,d.jsx)(Hn.c,{name:e.connectionHost,path:(0,Vo.vI)(e.connectionNodeId),showStatus:!1,hasClipboardButton:!0}):"\u2013"}],Ed=Nd.filter((e=>pd.includes(e.name))),wd=(0,c.cn)("ydb-diagnostics-partitions"),Cd=({path:e,database:t})=>{const a=(0,X.YQ)(),[r,s]=n.useState([]),i=(0,X.N4)((a=>ba(a,e,t))),[o]=(0,X.Nt)(),{selectedConsumer:l}=(0,X.N4)((e=>e.partitions)),{currentData:c,isFetching:u,error:m}=va.useGetTopicQuery({path:e,database:t}),p=u&&void 0===c,{currentData:h,isFetching:v,error:g}=Kc.m.useGetNodesListQuery(void 0),x=v&&void 0===h,b=(0,X.N4)(Kc.K),[f,j]=(0,X.iK)(Z.bs),[S,T]=(e=>{const[t,a]=n.useState([]),[r,s]=n.useState([]);return n.useEffect((()=>{e?(a(Nd),s(hd)):(a(Ed),s(pd))}),[e]),[t,r]})(l),N=p?y.hT:{path:e,database:t,consumerName:l},{currentData:E,isFetching:w,error:C}=Zc.aD.useGetPartitionsQuery(N,{pollingInterval:o}),P=w&&void 0===E,I=E,D=n.useMemo((()=>((e=[],t)=>null===e||void 0===e?void 0:e.map((e=>{var a,n;const r=e.partitionNodeId&&t?null===(a=t.get(e.partitionNodeId))||void 0===a?void 0:a.Host:void 0,s=e.connectionNodeId&&t?null===(n=t.get(e.connectionNodeId))||void 0===n?void 0:n.Host:void 0;return{...e,partitionHost:r,connectionHost:s}})))(I,b)),[I,b]);n.useEffect((()=>{const e=!p&&!i,t=l&&i&&!i.includes(l);(e||t)&&a((0,Zc.WD)(void 0))}),[a,p,l,i]);const A=n.useMemo((()=>S.filter((e=>!f.includes(e.name)))),[S,f]),_=e=>{j(e)},R=e=>{a((0,Zc.WD)(e))},k=p||x||P,O=g||m||C;return(0,d.jsxs)("div",{className:wd(),children:[(0,d.jsx)("div",{className:wd("controls"),children:(0,d.jsx)(vd,{consumers:i,selectedConsumer:l,onSelectedConsumerChange:R,selectDisabled:Boolean(O)||k,partitions:D,onSearchChange:s,hiddenColumns:f,onHiddenColumnsChange:_,initialColumnsIds:T})}),O?(0,d.jsx)(de.o,{error:O}):null,(0,d.jsx)("div",{className:wd("table-wrapper"),children:(0,d.jsx)("div",{className:wd("table-content"),children:E?k?(0,d.jsx)(Tt.Q,{className:wd("loader")}):(0,d.jsx)(Fe.l,{columnsWidthLSKey:"partitionsColumnsWidth",wrapperClassName:wd("table"),data:r,columns:A,settings:Z.N3,emptyDataMessage:nd("table.emptyDataMessage")}):null})})]})};var Pd=a(44433),Id=a(23812);const Dd=JSON.parse('{"date-format":"MM/DD/YYYY","date-time-format":"MM/DD/YYYY HH:mm"}'),Ad=JSON.parse('{"date-format":"DD.MM.YYYY","date-time-format":"DD.MM.YYYY HH:mm"}'),_d=(0,$e.g4)("ydb-date-range",{ru:Ad,en:Dd});function Rd(e){var t,a,n,r;return"relative"===(null===e||void 0===e||null===(t=e.start)||void 0===t?void 0:t.type)&&"relative"===(null===e||void 0===e||null===(a=e.end)||void 0===a?void 0:a.type)?"s":"relative"===(null===e||void 0===e||null===(n=e.start)||void 0===n?void 0:n.type)||"relative"===(null===e||void 0===e||null===(r=e.end)||void 0===r?void 0:r.type)?"m":"l"}const kd=(0,c.cn)("date-range"),Od={start:{value:"now-1h",type:"relative"},end:{value:"now",type:"relative"}},Md=({from:e,to:t,className:a,onChange:r})=>{const s=n.useCallback((e=>null===r||void 0===r?void 0:r(function(e){var t,a,n,r,s,i;return{from:"relative"===(null===e||void 0===e||null===(t=e.start)||void 0===t?void 0:t.type)?e.start.value.toString():String(null===(a=(0,nt.bQ)(null===e||void 0===e||null===(n=e.start)||void 0===n?void 0:n.value))||void 0===a?void 0:a.valueOf()),to:"relative"===(null===e||void 0===e||null===(r=e.end)||void 0===r?void 0:r.type)?e.end.value.toString():String(null===(s=(0,nt.bQ)(null===e||void 0===e||null===(i=e.end)||void 0===i?void 0:i.value))||void 0===s?void 0:s.valueOf())}}(e))),[r]),i=n.useMemo((()=>{if(e||t)return function(e){var t,a;const n=(0,nt.eP)(null!==(t=e.from)&&void 0!==t?t:""),r=(0,nt.eP)(null!==(a=e.to)&&void 0!==a?a:"");return{start:e.from?{type:n?"relative":"absolute",value:n?e.from:(0,nt.bQ)(Number(e.from))}:null,end:e.to?{type:r?"relative":"absolute",value:r?e.to:(0,nt.bQ)(Number(e.to))}:null}}({from:e,to:t})}),[e,t]),o=Intl.DateTimeFormat().resolvedOptions().timeZone;return(0,d.jsx)("div",{className:kd(null,a),children:(0,d.jsx)(Id.k,{withPresets:!0,className:kd("range-input",{[Rd(i)]:!0}),timeZone:o,value:i||Od,allowNullableValues:!0,size:"m",format:_d("date-time-format"),onUpdate:s,placeholder:`${_d("date-time-format")} - ${_d("date-time-format")}`,withApplyButton:!0})})},Ld=JSON.parse('{"no-data":"No data","filter.text.placeholder":"Search by query text or userSID...","mode_top":"Top","mode_running":"Running"}'),zd=(0,$e.g4)("ydb-diagnostics-top-queries",{en:Ld}),Fd={...lo,disableSortReset:!0};function qd(e){const[t,a]=(0,X.GY)({initialSortColumn:e,initialSortOrder:-1,multiple:!0}),r=n.useMemo((()=>(0,X.JN)(t,wo)),[t]);return{tableSort:t,handleTableSort:a,backendSort:r}}const Qd=({database:e,onRowClick:t,rowClassName:a})=>{var r;const[s]=(0,X.Nt)(),i=(0,X.N4)((e=>e.executeTopQueries)),{tableSort:o,handleTableSort:l,backendSort:c}=qd(So),{currentData:u,isFetching:m,error:p}=Di.Ke.useGetRunningQueriesQuery({database:e,filters:i,sortOrder:c},{pollingInterval:s}),h=m&&void 0===u,v=(null===u||void 0===u||null===(r=u.resultSets)||void 0===r?void 0:r[0].result)||[],g=n.useMemo((()=>[ko,zo,Do,Fo].map((e=>({...e,sortable:Co(e.name)})))),[]);return(0,d.jsxs)(n.Fragment,{children:[p?(0,d.jsx)(de.o,{error:(0,Nt.Cb)(p)}):null,(0,d.jsx)(qe.L.Table,{loading:h,children:(0,d.jsx)(Fe.l,{emptyDataMessage:zd("no-data"),columnsWidthLSKey:"runningQueriesColumnsWidth",columns:g,data:v,settings:Fd,onRowClick:e=>t(e.QueryText),rowClassName:()=>a,sortOrder:o,onSort:l})})]})},Ud=({database:e,onRowClick:t,rowClassName:a})=>{var r,s;const[i]=(0,X.Nt)(),o=(0,X.N4)((e=>e.executeTopQueries)),{tableSort:l,handleTableSort:c,backendSort:u}=qd(po),{currentData:m,isFetching:p,error:h}=Di.Ke.useGetTopQueriesQuery({database:e,filters:o,sortOrder:u},{pollingInterval:i}),v=p&&void 0===m,g=(null===m||void 0===m||null===(r=m.resultSets)||void 0===r||null===(s=r[0])||void 0===s?void 0:s.result)||[],y=n.useMemo((()=>[Mo,Io,Do,Ao,Lo,_o,Ro,ko].map((e=>({...e,sortable:Co(e.name)})))),[]);return(0,d.jsxs)(n.Fragment,{children:[h?(0,d.jsx)(de.o,{error:(0,Nt.Cb)(h)}):null,(0,d.jsx)(qe.L.Table,{loading:v,children:(0,d.jsx)(Fe.l,{emptyDataMessage:zd("no-data"),columnsWidthLSKey:mo,columns:y,data:g||[],settings:Fd,onRowClick:e=>t(e.QueryText),rowClassName:()=>a,sortOrder:l,onSort:c})})]})},Bd=(0,c.cn)("kv-top-queries"),$d={top:"top",running:"running"},Hd=[{value:$d.top,get content(){return zd("mode_top")}},{value:$d.running,get content(){return zd("mode_running")}}],Gd=xt.z.nativeEnum($d).catch($d.top),Wd=({tenantName:e})=>{const t=(0,X.YQ)(),a=(0,Xn.zy)(),r=(0,Xn.W6)(),[i=$d.top,o]=(0,s.useQueryParam)("queryMode",s.StringParam),l=Gd.parse(i),c=l===$d.top,u=(0,X.N4)((e=>e.executeTopQueries)),m=no(n.useCallback((e=>{t((0,Ai.iZ)({input:e}));const n=(0,ye.mA)(a),s=(0,na.YL)({...n,[ae.Dt]:ae.Dg.query,[na.vh.queryTab]:ae.tQ.newQuery});r.push(s)}),[t,r,a])),p=c?Ud:Qd;return(0,d.jsxs)(qe.L,{children:[(0,d.jsxs)(qe.L.Controls,{children:[(0,d.jsx)(Pd.a,{options:Hd,value:l,onUpdate:o}),(0,d.jsx)(Be.v,{value:u.text,onChange:e=>{t((0,Di.TX)({text:e}))},placeholder:zd("filter.text.placeholder"),className:Bd("search")}),c?(0,d.jsx)(Md,{from:u.from,to:u.to,onChange:e=>{t((0,Di.TX)(e))}}):null]}),(0,d.jsx)(p,{database:e,onRowClick:m,rowClassName:Bd("row")})]})};var Vd=a(46496),Jd=a(87747);const Yd=JSON.parse('{"no-data":"No data","filters.mode.immediate":"Immediate","filters.mode.history":"Historical","description":"Historical data only tracks shards with CPU load over 70%"}'),Kd=JSON.parse('{"no-data":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445","filters.mode.immediate":"\u041c\u0433\u043d\u043e\u0432\u0435\u043d\u043d\u044b\u0435","filters.mode.history":"\u0418\u0441\u0442\u043e\u0440\u0438\u0447\u0435\u0441\u043a\u0438\u0435","description":"\u0418\u0441\u0442\u043e\u0440\u0438\u0447\u0435\u0441\u043a\u0438\u0435 \u0434\u0430\u043d\u043d\u044b\u0435 \u0445\u0440\u0430\u043d\u044f\u0442\u0441\u044f \u0442\u043e\u043b\u044c\u043a\u043e \u043e \u0448\u0430\u0440\u0434\u0430\u0445 \u0441 \u0437\u0430\u0433\u0440\u0443\u0437\u043a\u043e\u0439 CPU \u0432\u044b\u0448\u0435 70%"}'),Zd=(0,$e.g4)("ydb-diagnostics-top-shards",{ru:Kd,en:Yd}),Xd=({value:e,onChange:t})=>{const a=e.mode===Jd.h.Immediate?void 0:e.from,r=e.mode===Jd.h.Immediate?void 0:e.to;return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)(Pd.a,{value:e.mode,onUpdate:e=>{if(!((e,t)=>Object.values(e).includes(t))(Jd.h,e)){const t=Object.values(Jd.h).join(", ");throw new Error(`Unexpected TopShards mode "${e}". Should be one of: ${t}`)}t({mode:e})},children:[(0,d.jsx)(Pd.a.Option,{value:Jd.h.Immediate,children:Zd("filters.mode.immediate")}),(0,d.jsx)(Pd.a.Option,{value:Jd.h.History,children:Zd("filters.mode.history")})]}),(0,d.jsx)(Md,{from:a,to:r,onChange:e=>{t({mode:Jd.h.History,...e})}})]})};const eu=(0,c.cn)("top-shards"),tu={...Z.N3,dynamicRender:!1,externalSort:!0,disableSortReset:!0,defaultOrder:Rt.Ay.DESCENDING};function au(e){return e?(0,he.r6)(new Date(e).getTime()):"\u2013"}function nu(e){return e.to="now",e.from="now-1h",e}const ru=({tenantName:e,path:t,type:a})=>{var r,s;const i=(0,X.YQ)(),o=(0,Xn.zy)(),[l]=(0,X.Nt)(),c=(0,X.N4)((e=>e.shardsWorkload)),[u,m]=n.useState((()=>{const e={...c};return e.mode||(e.mode=Jd.h.Immediate),e.from||e.to||nu(e),e})),{tableSort:p,handleTableSort:h,backendSort:v}=function(){const[e,t]=(0,X.GY)({initialSortColumn:Xo,fixedOrderType:-1,multiple:!0}),a=n.useMemo((()=>(0,X.JN)(e,ll)),[e]);return{tableSort:e,handleTableSort:t,backendSort:a}}(),{currentData:g,isFetching:y,error:x}=Vd.Xx.useSendShardQueryQuery({database:e,path:t,sortOrder:v,filters:u},{pollingInterval:l}),b=y&&void 0===g,f=(null===g||void 0===g||null===(r=g.resultSets)||void 0===r||null===(s=r[0])||void 0===s?void 0:s.result)||[],j=e=>{const t={...e};if(!c.from&&!c.to&&!e.from&&!e.to)switch(e.mode){case Jd.h.Immediate:t.from=t.to=void 0;break;case Jd.h.History:nu(t)}i((0,Vd.rF)(e)),m((e=>({...e,...t})))},S=n.useMemo((()=>{const t=((e,t)=>[cl(e,t),dl,ul,ml,pl,vl])(e,o),a=t.map((e=>{return{...e,sortable:(t=e.name,Boolean(ll(t)))};var t}));return u.mode===Jd.h.History&&(a.splice(5,0,{name:nl,render:({row:e})=>au(e.PeakTime),sortable:!1}),a.push({name:sl,render:({row:e})=>au(e.IntervalEnd)})),a}),[u.mode,o,e]);return(0,d.jsxs)(qe.L,{children:[(0,d.jsx)(qe.L.Controls,{children:(0,d.jsx)(Xd,{value:u,onChange:j})}),u.mode===Jd.h.History&&(0,d.jsx)("div",{className:eu("hint"),children:Zd("description")}),x?(0,d.jsx)(de.o,{error:(0,Nt.Cb)(x)}):null,(0,d.jsx)(qe.L.Table,{loading:b,children:x&&!f?null:!f||k(a)?Zd("no-data"):(0,d.jsx)(Fe.l,{columnsWidthLSKey:Ko,columns:S,data:f,settings:tu,onSort:h,sortOrder:p})})]})},su=(0,c.cn)("kv-tenant-diagnostics");const iu=function(e){const t=n.useRef(null),a=(0,X.YQ)(),{diagnosticsTab:i=ae.iJ.overview}=(0,X.N4)((e=>e.tenant)),[o]=(0,s.useQueryParams)({database:s.StringParam,schema:s.StringParam,backend:s.StringParam,clusterName:s.StringParam}),l=M(e.type)?e.path:e.tenantName,c=M(e.type)||e.path===e.tenantName,u=(0,ie._Q)(),m=c?(({hasFeatureFlags:e})=>e?Yl:Yl.filter((e=>e.id!==ae.iJ.configs)))({hasFeatureFlags:u}):(p=e.type)&&sc[p]||Xl;var p;let h=m.find((e=>e.id===i));return h||(h=m[0]),n.useEffect((()=>{h&&h.id!==i&&a((0,oe.WO)(h.id))}),[h,i,a]),(0,d.jsxs)("div",{className:su(),children:[h?(0,d.jsx)(r.mg,{children:(0,d.jsx)("title",{children:h.title})}):null,(()=>{var e;return(0,d.jsx)("div",{className:su("header-wrapper"),children:(0,d.jsxs)("div",{className:su("tabs"),children:[(0,d.jsx)(ne.t,{size:"l",items:m,activeTab:null===(e=h)||void 0===e?void 0:e.id,wrapTo:({id:e},t)=>{const a=(0,na.YL)({...o,[na.vh.diagnosticsTab]:e});return(0,d.jsx)(re.N_,{to:a,className:su("tab"),children:t},e)},allowNotSelected:!0}),(0,d.jsx)(se.E,{})]})})})(),(0,d.jsx)("div",{className:su("page-wrapper"),ref:t,children:(()=>{var a;const{type:n,path:r}=e;switch(null===(a=h)||void 0===a?void 0:a.id){case ae.iJ.overview:return(0,d.jsx)(Ol,{type:n,tenantName:l,path:r,additionalTenantProps:e.additionalTenantProps,additionalNodesProps:e.additionalNodesProps});case ae.iJ.schema:return(0,d.jsx)(aa,{path:r,tenantName:l,type:n,extended:!0});case ae.iJ.topQueries:return(0,d.jsx)(Wd,{tenantName:l});case ae.iJ.topShards:return(0,d.jsx)(ru,{tenantName:l,path:r,type:n});case ae.iJ.nodes:return(0,d.jsx)(Le.G,{path:r,database:l,additionalNodesProps:e.additionalNodesProps,parentRef:t});case ae.iJ.tablets:return(0,d.jsx)(St.C,{path:r,database:l});case ae.iJ.storage:return(0,d.jsx)(jt.z,{database:l,parentRef:t});case ae.iJ.network:return(0,d.jsx)(Yc,{path:r,database:l,additionalNodesProps:e.additionalNodesProps,parentRef:t});case ae.iJ.describe:return(0,d.jsx)(Nn,{path:r,database:l,type:n});case ae.iJ.hotKeys:return(0,d.jsx)(gc,{path:r,database:l});case ae.iJ.graph:return(0,d.jsx)(Me,{path:r,database:l});case ae.iJ.consumers:return(0,d.jsx)(un,{path:r,database:l,type:n});case ae.iJ.partitions:return(0,d.jsx)(Cd,{path:r,database:l});case ae.iJ.configs:return(0,d.jsx)(ua,{database:l});case ae.iJ.operations:return(0,d.jsx)(ft,{database:l});default:return(0,d.jsx)("div",{children:"No data..."})}})()})]})},ou=JSON.parse('{"controls.query-mode-selector_type":"Query type:","tabs.newQuery":"Editor","tabs.history":"History","tabs.saved":"Saved","history.empty":"History is empty","history.empty-search":"Search result is empty","saved.empty":"There are no saved queries","delete-dialog.header":"Delete query","delete-dialog.question":"Are you sure you want to delete query","delete-dialog.delete":"Delete","delete-dialog.cancel":"Cancel","preview.title":"Preview","preview.not-available":"Preview is not available","preview.close":"Close preview","preview.truncated":"truncated","method-description.script":"For YQL-scripts combining DDL and DML.\\nAPI call: schema.scripting","method-description.scan":"Read-only queries, potentially reading a lot of data.\\nAPI call: table.ExecuteScan","method-description.data":"DML queries for changing and fetching data in serialization mode.\\nAPI call: table.executeDataQuery","method-description.query":"Any query. An experimental API call supposed to replace all existing methods.\\nAPI Call: query.ExecuteScript","method-description.pg":"Queries in postgresql syntax.\\nAPI call: query.ExecuteScript","transaction-mode-description.serializable":"Provides the strictest isolation level for custom transactions","transaction-mode-description.onlinero":"Each read operation in the transaction is reading the data that is most recent at execution time","transaction-mode-description.stalero":"Read operations within a transaction may return results that are slightly out-of-date (lagging by fractions of a second)","transaction-mode-description.snapshot":"All the read operations within a transaction access the database snapshot. All the data reads are consistent","transaction-mode-description.implicit":"No transaction","tracing-level-description.basic":"Spans of main component operations","tracing-level-description.detailed":"Highest detail applicable for diagnosing problems in production","tracing-level-description.diagnostic":"Detailed debugging information for developers","tracing-level-description.off":"No tracing","tracing-level-description.toplevel":"Lowest detail, no more than two spans per request to the component","tracing-level-description.trace":"Very detailed debugging information","statistics-mode-description.none":"Don\'t collect statistics","statistics-mode-description.basic":"Collect statistics","statistics-mode-description.full":"Collect statistics and query plan","statistics-mode-description.profile":"Collect statistics for individual tasks","query-duration.description":"Duration of server-side query execution","action.send-query":"Send query","action.send-selected-query":"Send selected query","action.previous-query":"Previous query in history","action.next-query":"Next query in history","action.save-query":"Save query","action.stop":"Stop","filter.text.placeholder":"Search by query text...","gear.tooltip":"Query execution settings have been changed for ","banner.query-settings.message":"Query was executed with modified settings: ","history.queryText":"Query text","history.endTime":"End time","history.duration":"Duration"}'),lu=(0,$e.g4)("ydb-query-editor",{en:ou}),cu=(0,c.cn)("ydb-queries-history");const du=function({changeUserInput:e}){const t=(0,X.YQ)(),a=(0,X.N4)(Ai.py),n=(0,X.N4)(Ai.jY),r=[...a].reverse(),s=no((a=>{e({input:a.queryText}),t((0,oe.sH)(ae.tQ.newQuery))})),i=[{name:"queryText",header:lu("history.queryText"),render:({row:e})=>(0,d.jsx)("div",{className:cu("query"),children:(0,d.jsx)(so,{value:e.queryText,maxQueryHeight:6})}),sortable:!1,width:600},{name:"EndTime",header:lu("history.endTime"),render:({row:e})=>e.endTime?(0,he.r6)(e.endTime.toString()):"-",align:"right",width:200,sortable:!1},{name:"Duration",header:lu("history.duration"),render:({row:e})=>e.durationUs?(0,vt.Xo)((0,vt.Jc)(e.durationUs)):"-",align:"right",width:150,sortable:!1}];return(0,d.jsxs)(qe.L,{className:cu(),children:[(0,d.jsx)(qe.L.Controls,{children:(0,d.jsx)(Be.v,{value:n,onChange:e=>{t((0,Ai.Ni)(e))},placeholder:lu("filter.text.placeholder"),className:cu("search")})}),(0,d.jsx)(qe.L.Table,{children:(0,d.jsx)(Fe.l,{columnsWidthLSKey:"queriesHistoryTableColumnsWidth",columns:i,data:r,settings:lo,emptyDataMessage:lu(n?"history.empty-search":"history.empty"),onRowClick:e=>s(e),rowClassName:()=>cu("table-row")})})]})};var uu=a(13847),mu=a(72093);function pu(e,t){const a=new Map(Object.entries(e)),n=new Map(Object.entries(t));return Array.from(a.keys()).filter((e=>a.has(e)&&void 0!==a.get(e)&&a.get(e)!==n.get(e)))}const hu=JSON.parse('{"action.settings":"Query settings","form.query-mode":"Query type","form.timeout":"Timeout","form.transaction-mode":"Transaction mode","form.statistics-mode":"Statistics collection mode","form.tracing-level":"Tracing level","form.limit-rows":"Limit rows","button-done":"Save","tooltip_plan-to-svg-statistics":"Statistics option is set to \\"Full\\" due to the enabled \\"Execution plan\\" experiment.\\n To disable it, go to the \\"Experiments\\" section in the user settings.","button-cancel":"Cancel","form.timeout.seconds":"sec","form.validation.timeout":"Must be positive","form.validation.limitRows":"Must be between 1 and 100000","description.default":" (default)","docs":"Documentation"}'),vu=JSON.parse('{"action.settings":"\u041d\u0430\u0441\u0442\u0440\u043e\u0439\u043a\u0438 \u0437\u0430\u043f\u0440\u043e\u0441\u0430","form.query-mode":"\u0422\u0438\u043f \u0437\u0430\u043f\u0440\u043e\u0441\u0430","form.timeout":"\u0422\u0430\u0439\u043c\u0430\u0443\u0442","form.transaction-mode":"\u0423\u0440\u043e\u0432\u0435\u043d\u044c \u0438\u0437\u043e\u043b\u044f\u0446\u0438\u0438","form.statistics-mode":"\u0420\u0435\u0436\u0438\u043c \u0441\u0431\u043e\u0440\u0430 \u0441\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0438","form.tracing-level":"Tracing level","form.limit-rows":"\u041b\u0438\u043c\u0438\u0442 \u0441\u0442\u0440\u043e\u043a","tooltip_plan-to-svg-statistics":"\u041e\u043f\u0446\u0438\u044f \u0441\u0442\u0430\u0442\u0438\u0441\u0442\u0438\u043a\u0438 \u0443\u0441\u0442\u0430\u043d\u043e\u0432\u043b\u0435\u043d\u0430 \u0432 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \\"Full\\" \u0438\u0437-\u0437\u0430 \u0432\u043a\u043b\u044e\u0447\u0435\u043d\u043d\u043e\u0433\u043e \u044d\u043a\u0441\u043f\u0435\u0440\u0438\u043c\u0435\u043d\u0442\u0430 \\"Execution plan\\".\\n \u0427\u0442\u043e\u0431\u044b \u043e\u0442\u043a\u043b\u044e\u0447\u0438\u0442\u044c \u0435\u0433\u043e, \u043f\u0435\u0440\u0435\u0439\u0434\u0438\u0442\u0435 \u0432 \u0440\u0430\u0437\u0434\u0435\u043b \\"Experiments\\" \u0432 \u043d\u0430\u0441\u0442\u0440\u043e\u0439\u043a\u0430\u0445 \u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u0435\u043b\u044f.","button-done":"\u0413\u043e\u0442\u043e\u0432\u043e","button-cancel":"\u041e\u0442\u043c\u0435\u043d\u0438\u0442\u044c","form.timeout.seconds":"\u0441\u0435\u043a","form.validation.timeout":"\u0422\u0430\u0439\u043c\u0430\u0443\u0442 \u0434\u043e\u043b\u0436\u0435\u043d \u0431\u044b\u0442\u044c \u043f\u043e\u043b\u043e\u0436\u0438\u0442\u0435\u043b\u044c\u043d\u044b\u043c","form.validation.limitRows":"\u041b\u0438\u043c\u0438\u0442 \u0441\u0442\u0440\u043e\u043a \u0434\u043e\u043b\u0436\u0435\u043d \u0431\u044b\u0442\u044c \u043c\u0435\u0436\u0434\u0443 1 \u0438 100000","description.default":" (default)","docs":"\u0414\u043e\u043a\u0443\u043c\u0435\u043d\u0442\u0430\u0446\u0438\u044f"}'),gu=(0,$e.g4)("ydb-query-settings-dialog",{en:hu,ru:vu}),yu=[{value:Nt.Wg.implicit,content:Nt._d[Nt.Wg.implicit],text:lu("transaction-mode-description.implicit"),isDefault:!0},{value:Nt.Wg.serializable,content:Nt._d[Nt.Wg.serializable],text:lu("transaction-mode-description.serializable")},{value:Nt.Wg.onlinero,content:Nt._d[Nt.Wg.onlinero],text:lu("transaction-mode-description.onlinero")},{value:Nt.Wg.stalero,content:Nt._d[Nt.Wg.stalero],text:lu("transaction-mode-description.stalero")},{value:Nt.Wg.snapshot,content:Nt._d[Nt.Wg.snapshot],text:lu("transaction-mode-description.snapshot")}],xu=[{value:Nt.ei.query,content:Nt.om[Nt.ei.query],text:lu("method-description.query"),isDefault:!0},{value:Nt.ei.script,content:Nt.om[Nt.ei.script],text:lu("method-description.script")},{value:Nt.ei.scan,content:Nt.om[Nt.ei.scan],text:lu("method-description.scan")},{value:Nt.ei.data,content:Nt.om[Nt.ei.data],text:lu("method-description.data")},{value:Nt.ei.pg,content:Nt.om[Nt.ei.pg],text:lu("method-description.pg")}],bu=[{value:Nt.pE.none,content:Nt.Pn[Nt.pE.none],text:lu("statistics-mode-description.none"),isDefault:!0},{value:Nt.pE.basic,content:Nt.Pn[Nt.pE.basic],text:lu("statistics-mode-description.basic")},{value:Nt.pE.full,content:Nt.Pn[Nt.pE.full],text:lu("statistics-mode-description.full")},{value:Nt.pE.profile,content:Nt.Pn[Nt.pE.profile],text:lu("statistics-mode-description.profile")}],fu=[{value:Nt.PB.off,content:Nt.PX[Nt.PB.off],text:lu("tracing-level-description.off"),isDefault:!0},{value:Nt.PB.toplevel,content:Nt.PX[Nt.PB.toplevel],text:lu("tracing-level-description.toplevel")},{value:Nt.PB.basic,content:Nt.PX[Nt.PB.basic],text:lu("tracing-level-description.basic")},{value:Nt.PB.detailed,content:Nt.PX[Nt.PB.detailed],text:lu("tracing-level-description.detailed")},{value:Nt.PB.diagnostic,content:Nt.PX[Nt.PB.diagnostic],text:lu("tracing-level-description.diagnostic")},{value:Nt.PB.trace,content:Nt.PX[Nt.PB.trace],text:lu("tracing-level-description.trace")}],ju={transactionMode:{title:gu("form.transaction-mode"),options:yu},queryMode:{title:gu("form.query-mode"),options:xu},statisticsMode:{title:gu("form.statistics-mode"),options:bu},tracingLevel:{title:gu("form.tracing-level"),options:fu},timeout:{title:gu("form.timeout")},limitRows:{title:gu("form.limit-rows")}};function Su({currentSettings:e,defaultSettings:t}){const a=pu(e,t),n={};return a.forEach((t=>{const a=ju[t],r=e[t];if("options"in a){var s;const e=null===(s=a.options.find((e=>e.value===r)))||void 0===s?void 0:s.content;e&&(n[a.title]=e)}else r&&(n[a.title]=String(r))})),n}var Tu=a(80967);const Nu=()=>{const[e,t]=(0,Tu.i)(Z.fr);let a;try{a=Nt.id.parse(e)}catch{a=void 0}return[a,t]};var Eu=a(95312);const wu=()=>{const[e,t]=(0,Tu.i)(Z.YQ),[a]=Nu(),[n]=(0,Eu.X)(),r=a?pu(a,Nt.jU):[],s=n?pu(n,Nt.jU):[],i=r.length>0,o=a?Su({currentSettings:a,defaultSettings:Nt.jU}):{},l=n?Su({currentSettings:n,defaultSettings:Nt.jU}):{},c=e&&Date.now()-e<1e3*Z.Du;return{isBannerShown:i&&!c,isIndicatorShown:i&&c,closeBanner:()=>t(Date.now()),resetBanner:()=>t(void 0),changedCurrentSettings:s,changedCurrentSettingsDescriptions:l,changedLastExucutionSettings:r,changedLastExecutionSettingsDescriptions:o}};var Cu=a(53472);let Pu=function(e){return e.triggerCollapse="triggerCollapse",e.triggerExpand="triggerExpand",e.clear="clear",e}({});const Iu=e=>{localStorage.setItem(e,"true")},Du=e=>{localStorage.removeItem(e)};function Au(e){return function(t,a){switch(a){case Pu.triggerCollapse:return Iu(e),{...t,triggerCollapse:!0,triggerExpand:!1,collapsed:!0};case Pu.triggerExpand:return Du(e),{...t,triggerCollapse:!1,triggerExpand:!0,collapsed:!1};case Pu.clear:return Du(e),{triggerCollapse:!1,triggerExpand:!1,collapsed:!1};default:return t}}}const _u=(0,c.cn)("kv-pane-visibility-button");function Ru({onCollapse:e,onExpand:t,isCollapsed:a,initialDirection:r="top",className:s}){return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(lt.m,{title:"Collapse",children:(0,d.jsx)(hn.$,{view:"flat-secondary",onClick:e,className:_u({hidden:a,type:"collapse"},s),children:(0,d.jsx)(ct.I,{data:Cu.A,className:_u({[r]:!0})})})}),(0,d.jsx)(lt.m,{title:"Expand",children:(0,d.jsx)(hn.$,{view:"flat-secondary",onClick:t,className:_u({hidden:!a,type:"expand"},s),children:(0,d.jsx)(ct.I,{data:Cu.A,className:_u({[r]:!0},"rotate")})})})]})}var ku=a(31819),Ou=a(72976);const Mu=function({disabled:e}){const t=(0,X.YQ)();return(0,d.jsx)(hn.$,{onClick:()=>{t((0,Ou.Jf)())},view:"flat-secondary",disabled:e,title:"Fullscreen",children:(0,d.jsx)(ct.I,{data:ku.A})})};var Lu,zu=a(98392);function Fu(){return Fu=Object.assign?Object.assign.bind():function(e){for(var t=1;te.fullscreen)),r=(0,X.YQ)(),s=n.useCallback((()=>{r((0,Ou.sM)())}),[r]);n.useEffect((()=>{const e=e=>{"Escape"===e.key&&s()};return document.addEventListener("keydown",e,!1),()=>{document.removeEventListener("keydown",e,!1)}}),[s]);const[i,o]=n.useState(null);n.useEffect((()=>{const e=document.createElement("div");return null===Bu||void 0===Bu||Bu.appendChild(e),e.style.display="contents",o(e),()=>{o(null),e.remove()}}),[]);const l=n.useRef(null);return n.useLayoutEffect((()=>{var e;i&&(a?null===Bu||void 0===Bu||Bu.appendChild(i):null===(e=l.current)||void 0===e||e.appendChild(i))}),[i,a]),i?(0,d.jsx)("div",{ref:l,style:{display:"contents"},children:(0,d.jsx)(zu.Z,{container:i,children:(0,d.jsxs)("div",{className:Uu({fullscreen:a},t),children:[(0,d.jsx)(hn.$,{onClick:s,view:"raised",className:Uu("close-button"),children:(0,d.jsx)(ct.I,{data:qu})}),(0,d.jsx)("div",{className:Uu("content"),children:e})]})})}):null},Hu=n.memo((function(e){const{className:t,value:a}=e,n=(0,X.YQ)();return(0,d.jsx)("span",{className:Yu("cell",t),onClick:e=>n((0,pe.DK)(e.target,a,"cell")),children:a})})),Gu=JSON.parse('{"empty":"Table is empty"}'),Wu=JSON.parse('{"empty":"\u0422\u0430\u0431\u043b\u0438\u0446\u0430 \u043f\u0443\u0441\u0442\u0430\u044f"}'),Vu=(0,$e.g4)("ydb-query-result-table",{ru:Wu,en:Gu}),Ju={...Z.N3,stripedRows:!0,sortable:!1,displayIndices:!0},Yu=(0,c.cn)("ydb-query-result-table"),Ku=(e,t)=>t,Zu=(e,t)=>t+1,Xu=e=>{const{columns:t,data:a,...r}=e,s=n.useMemo((()=>(0,Nt.vi)(a)),[a]),i=n.useMemo((()=>t?((e,t)=>{if(!e.length)return[];const a=null===t||void 0===t?void 0:t.slice(0,100);return e.map((({name:e,type:t})=>{const n=(0,Nt.nh)(t);return{name:e,width:kt({data:a,name:e}),align:"number"===n?Rt.Ay.RIGHT:Rt.Ay.LEFT,render:({row:t})=>(0,d.jsx)(Hu,{value:String(t[e])})}}))})(t,s):(e=>{if(!e.length)return[];const t=null===e||void 0===e?void 0:e.slice(0,100);return Object.keys(e[0]).map((a=>({name:a,width:kt({data:t,name:a}),align:(0,$r.kf)(e[0][a])?Rt.Ay.RIGHT:Rt.Ay.LEFT,render:({row:e})=>(0,d.jsx)(Hu,{value:String(e[a])})})))})(s)),[s,t]);return Array.isArray(a)?i.length?(0,d.jsx)(Fe.l,{data:s,columns:i,settings:Ju,rowKey:Ku,visibleRowIndex:Zu,...r}):(0,d.jsx)("div",{className:Yu("message"),children:Vu("empty")}):null},em=H.F.injectEndpoints({endpoints:e=>({sendQuery:e.query({queryFn:async({query:e,database:t,action:a,limitRows:n},{signal:r})=>{try{const s=await window.api.viewer.sendQuery({query:e,database:t,action:a,limit_rows:n},{signal:r,withRetries:!0});return(0,Nt.We)(s)?{error:s}:{data:(0,Nt.fW)(s)}}catch(s){return{error:s||new Error("Unauthorized")}}},providesTags:["All","PreviewData"]})}),overrideExisting:"throw"}),tm=(0,c.cn)("kv-preview"),am=({database:e,path:t,type:a})=>{var n,r,s;const i=(0,X.YQ)(),o=D(a),l=`select * from \`${t}\` limit 101`,{currentData:c,isFetching:u,error:m}=em.useSendQueryQuery({database:e,query:l,action:U(a)?"execute-query":"execute-scan",limitRows:100},{skip:!o,refetchOnMountOrArgChange:!0}),p=u&&void 0===c,h=null!==(n=null===c||void 0===c||null===(r=c.resultSets)||void 0===r?void 0:r[0])&&void 0!==n?n:{},v=()=>{i((0,K.o)(!1))};if(p)return(0,d.jsx)("div",{className:tm("loader-container"),children:(0,d.jsx)(Zr.a,{size:"m"})});let g;o?m&&(g=(0,d.jsx)("div",{className:tm("message-container","error"),children:(0,Nt.Cb)(m)})):g=(0,d.jsx)("div",{className:tm("message-container"),children:lu("preview.not-available")});const y=null!==(s=g)&&void 0!==s?s:(0,d.jsx)("div",{className:tm("result"),children:(0,d.jsx)(Xu,{data:h.result,columns:h.columns})});return(0,d.jsxs)("div",{className:tm(),children:[(()=>{var e,a;return(0,d.jsxs)("div",{className:tm("header"),children:[(0,d.jsxs)("div",{className:tm("title"),children:[lu("preview.title"),(0,d.jsxs)(it.E,{color:"secondary",variant:"body-2",children:[h.truncated?`${lu("preview.truncated")} `:"","(",null!==(e=null===(a=h.result)||void 0===a?void 0:a.length)&&void 0!==e?e:0,")"]}),(0,d.jsx)("div",{className:tm("table-name"),children:t})]}),(0,d.jsxs)("div",{className:tm("controls-left"),children:[(0,d.jsx)(Mu,{disabled:Boolean(m)}),(0,d.jsx)(hn.$,{view:"flat-secondary",onClick:v,title:lu("preview.close"),children:(0,d.jsx)(ct.I,{data:ic.A,size:18})})]})]})})(),(0,d.jsx)($u,{children:y})]})};var nm=a(27738),rm=a(594),sm=a(1155);const im=(0,c.cn)("ydb-query-settings-description"),om=({querySettings:e,prefix:t})=>(0,d.jsxs)("div",{className:im("message"),children:[t,Object.entries(e).map((([e,t],a,n)=>(0,d.jsxs)("span",{className:im("description-item"),children:[`${e}: ${t}`,a{if(!window.ydbEditor){if(!a)return!1;await new Promise((e=>{window.setTimeout(e,100)})),a-=1,n()}return!0};await n()?null===(t=window.ydbEditor)||void 0===t||t.trigger(void 0,"insertSnippetToEditor",e):console.error("Monaco editor not found")}const dm=e=>`-- docs: https://ydb.tech/en/docs/yql/reference/syntax/create_table\nCREATE TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}/my_row_table\``:"${1:my_row_table}"} (\n category_id Uint64 NOT NULL,\n id Uint64,\n expire_at Datetime,\n updated_on Datetime,\n name Text,\n \`binary-payload\` Bytes,\n attributes JsonDocument,\n -- uncomment to add a secondary index\n -- INDEX idx_row_table_id GLOBAL SYNC ON ( id ) COVER ( name, attributes ), -- Secondary indexes docs https://ydb.tech/en/docs/yql/reference/syntax/create_table#secondary_index\n PRIMARY KEY (category_id, id)\n) \nWITH (\n AUTO_PARTITIONING_BY_SIZE = ENABLED,\n AUTO_PARTITIONING_PARTITION_SIZE_MB = 2048,\n AUTO_PARTITIONING_BY_LOAD = ENABLED,\n AUTO_PARTITIONING_MIN_PARTITIONS_COUNT = 4,\n AUTO_PARTITIONING_MAX_PARTITIONS_COUNT = 1024\n -- uncomment to create a table with predefined partitions\n -- , UNIFORM_PARTITIONS = 4 -- The number of partitions for uniform initial table partitioning.\n -- The primary key's first column must have type Uint64 or Uint32.\n -- A created table is immediately divided into the specified number of partitions\n -- uncomment to launch read only replicas in every AZ\n -- , READ_REPLICAS_SETTINGS = 'PER_AZ:1' -- Enable read replicas for stale read, launch one replica in every availability zone\n -- uncomment to enable ttl\n -- , TTL = Interval("PT1H") ON expire_at -- Enable background deletion of expired rows https://ydb.tech/en/docs/concepts/ttl\n -- uncomment to create a table with a bloom filter\n -- , KEY_BLOOM_FILTER = ENABLED -- With a Bloom filter, you can more efficiently determine\n -- if some keys are missing in a table when making multiple single queries by the primary key.\n)`,um=e=>`-- docs: https://ydb.tech/en/docs/yql/reference/syntax/create_table#olap-tables\nCREATE TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}/my_column_table\``:"${1:my_column_table}"} (\n id Int64 NOT NULL,\n author Text,\n title Text,\n body Text,\n PRIMARY KEY (id)\n)\nPARTITION BY HASH(id)\nWITH (STORE = COLUMN)`,mm=()=>'-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-async-replication\nCREATE OBJECT secret_name (TYPE SECRET) WITH value="secret_value";\n\nCREATE ASYNC REPLICATION my_replication\nFOR ${1:} AS ${2:replica_table} --[, `/remote_database/another_table_name` AS `another_local_table_name` ...]\nWITH (\n CONNECTION_STRING="${3:grpcs://mydb.ydb.tech:2135/?database=/remote_database}",\n TOKEN_SECRET_NAME = "secret_name"\n -- ENDPOINT="mydb.ydb.tech:2135",\n -- DATABASE=`/remote_database`,\n -- USER="user",\n -- PASSWORD_SECRET_NAME="your_password"\n);',pm=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter_table/\n\nALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"}\n -- RENAME TO new_table_name\n -- DROP COLUMN some_existing_column\n\${2:ADD COLUMN numeric_column Int32};`,hm=e=>{var t;const a=null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${2:}";return`SELECT ${(null===e||void 0===e||null===(t=e.schemaData)||void 0===t?void 0:t.map((e=>"`"+e.name+"`")).join(", "))||"${1:*}"}\nFROM ${a}\n${null!==e&&void 0!==e&&e.relativePath?"":"WHERE ${3:Key1 = 1}\nORDER BY ${4:Key1}\n"}LIMIT \${5:10};`},vm=e=>{var t;return`UPSERT INTO ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"}\n( ${(null===e||void 0===e||null===(t=e.schemaData)||void 0===t?void 0:t.map((e=>`\`${e.name}\``)).join(", "))||"${2:id, name}"} )\nVALUES ( ${null!==e&&void 0!==e&&e.schemaData?"${3: }":'${3:1, "foo"}'} );`},gm=e=>`DROP EXTERNAL TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:my_table}"};`,ym=e=>{const t=null===e||void 0===e?void 0:e.relativePath.split("/").slice(0,-1).join("/");return`CREATE EXTERNAL TABLE ${t?`\`${t}/my_external_table\``:"${1:}"} (\n column1 Int,\n column2 Int\n) WITH (\n DATA_SOURCE="${null!==e&&void 0!==e&&e.relativePath?`${e.relativePath}`:"${2:}"}",\n LOCATION="",\n FORMAT="json_as_string",\n \`file_pattern\`=""\n);`},xm=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-topic\nCREATE TOPIC ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\`/my_topic`:"${1:my_topic}"} (\n CONSUMER consumer1,\n CONSUMER consumer2 WITH (read_from = Datetime('1970-01-01T00:00:00Z')) -- Sets up the message write time starting from which the consumer will receive data.\n -- Value type: Datetime OR Timestamp OR integer (unix-timestamp in the numeric format). \n -- Default value: now\n) WITH (\n min_active_partitions = 1, -- Minimum number of topic partitions.\n partition_count_limit = 0, -- Maximum number of active partitions in the topic. 0 is interpreted as unlimited.\n retention_period = Interval('PT18H'), -- Data retention period in the topic. Value type: Interval.\n retention_storage_mb = 0, -- Limit on the maximum disk space occupied by the topic data. \n -- When this value is exceeded, the older data is cleared, like under a retention policy. \n -- 0 is interpreted as unlimited.\n partition_write_speed_bytes_per_second = 1048576, -- Maximum allowed write speed per partition.\n partition_write_burst_bytes = 0 -- Write quota allocated for write bursts. \n -- When set to zero, the actual write_burst value is equalled to \n -- the quota value (this allows write bursts of up to one second).\n);`,bm=e=>`-- docs: https://ydb.tech/en/docs/yql/reference/syntax/alter_topic\nALTER TOPIC ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"}\n ADD CONSUMER new_consumer WITH (read_from = Datetime('1970-01-01T00:00:00Z')), -- Sets up the message write time starting from which the consumer will receive data.\n -- Value type: Datetime OR Timestamp OR integer (unix-timestamp in the numeric format).\n -- Default value: now\n ALTER CONSUMER consumer1 SET (read_from = Datetime('1970-01-01T00:00:00Z')),\n DROP CONSUMER consumer2,\n SET (\n min_active_partitions = 1, -- Minimum number of topic partitions.\n partition_count_limit = 0, -- Maximum number of active partitions in the topic. 0 is interpreted as unlimited.\n retention_period = Interval('PT18H'), -- Data retention period in the topic. Value type: Interval.\n retention_storage_mb = 0, -- Limit on the maximum disk space occupied by the topic data. \n -- When this value is exceeded, the older data is cleared, like under a retention policy. \n -- 0 is interpreted as unlimited.\n partition_write_speed_bytes_per_second = 1048576, -- Maximum allowed write speed per partition.\n partition_write_burst_bytes = 0 -- Write quota allocated for write bursts. \n -- When set to zero, the actual write_burst value is equalled to\n -- the quota value (this allows write bursts of up to one second).\n );`,fm=e=>`DROP TOPIC ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"};`,jm=e=>`CREATE VIEW ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}/my_view\``:"${1:my_view}"} WITH (security_invoker = TRUE) AS SELECT 1;`,Sm=e=>`DROP VIEW ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"};`,Tm=e=>`DROP ASYNC REPLICATION ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"};`,Nm=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter-async-replication\nALTER ASYNC REPLICATION ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"} SET (STATE = "DONE", FAILOVER_MODE = "FORCE");`,Em=e=>`ALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"} ADD INDEX \${2:index_name} GLOBAL ON (\${3:});`,wm=e=>{const t=null===e||void 0===e?void 0:e.relativePath.split("/").pop(),a=null===e||void 0===e?void 0:e.relativePath.split("/").slice(0,-1).join("/");return`ALTER TABLE ${a?`\`${a}\``:"${1:}"} DROP INDEX ${t||"${2:}"};`},Cm=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/alter_table/changefeed\nALTER TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"} ADD CHANGEFEED \${2:changefeed_name} WITH (\n MODE = \${3:'UPDATES'}, -- KEYS_ONLY, UPDATES, NEW_IMAGE, OLD_IMAGE, or NEW_AND_OLD_IMAGES\n FORMAT = \${4:'JSON'}, -- JSON or DEBEZIUM_JSON\n VIRTUAL_TIMESTAMPS = \${5:TRUE}, -- true or false\n RETENTION_PERIOD = \${6:Interval('PT12H')}, -- Interval value, e.g., Interval('PT24H')\n -- TOPIC_MIN_ACTIVE_PARTITIONS: The number of topic partitions. By default, the number of topic partitions is equal to the number of table partitions\n INITIAL_SCAN = \${8:TRUE} -- true or false\n)\n\n-- MODE options:\n-- KEYS_ONLY: Only the primary key components and change flag are written.\n-- UPDATES: Updated column values that result from updates are written.\n-- NEW_IMAGE: Any column values resulting from updates are written.\n-- OLD_IMAGE: Any column values before updates are written.\n-- NEW_AND_OLD_IMAGES: A combination of NEW_IMAGE and OLD_IMAGE modes.`,Pm=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-group\nCREATE GROUP ${1:group_name}\n-- group_name: The name of the group. It may contain lowercase Latin letters and digits.",Im=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/create-user\nCREATE USER ${1:user_name} PASSWORD ${2:'password'}\n-- user_name: The name of the user. It may contain lowercase Latin letters and digits.\n-- option: The password of the user:\n -- PASSWORD 'password' creates a user with the password password. The ENCRYPTED option is always enabled.\n -- PASSWORD NULL creates a user with an empty password.",Dm=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/delete\nDELETE FROM ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"}\nWHERE \${2:Key1 = 1};`,Am=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/drop-group\nDROP GROUP ${1:}\n\n-- IF EXISTS: Suppress an error if the group doesn't exist.\n-- group_name: The name of the group to be deleted.",_m=()=>"-- docs: https://ydb.tech/docs/en/yql/reference/syntax/drop-user\nDROP USER ${1:}\n\n-- IF EXISTS: Suppress an error if the user doesn't exist.\n-- user_name: The name of the user to be deleted.",Rm=e=>`GRANT \${1:}\nON ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${2:}"}\nTO \${3:}\n\n-- permission_name: The name of the access right to schema objects that needs to be assigned.\n-- path_to_scheme_object: The path to the schema object for which rights are being granted.\n-- role_name: The name of the user or group to whom rights on the schema object are being granted.\n-- WITH GRANT OPTION: Using this construct gives the user or group of users the right to manage access rights - \n-- to assign or revoke certain rights. This construct has functionality similar to granting \n-- the "ydb.access.grant" or GRANT right. A subject with the ydb.access.grant right cannot \n-- grant rights broader than they possess themselves.`,km=e=>`REVOKE \${1:}\nON ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${2:}"}\nFROM \${3:}\n\n-- permission_name: The name of the access right to schema objects that needs to be revoked.\n-- path_to_scheme_object: The path to the schema object from which rights are being revoked.\n-- role_name: The name of the user or group from whom rights on the schema object are being revoked.\n-- GRANT OPTION FOR: Using this construct revokes the user's or group's right to manage access rights.\n-- All previously granted rights by this user remain in effect.\n-- This construct has functionality similar to revoking the "ydb.access.grant" or GRANT right.`,Om=e=>`-- docs: https://ydb.tech/docs/en/yql/reference/syntax/update\nUPDATE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"}\nSET \${2:Column1 = 'foo', Column2 = 'bar'}\nWHERE \${3:Key1 = 1};`,Mm=e=>`DROP TABLE ${null!==e&&void 0!==e&&e.relativePath?`\`${null===e||void 0===e?void 0:e.relativePath}\``:"${1:}"};`,Lm=JSON.parse('{"button.new-sql":"New query","action.create-row-table":"Create row table","action.create-column-table":"Create column table","action.create-external-table":"Create external table","action.upsert-to-table":"Upsert into table","action.update-table":"Update table","action.alter-table":"Alter table","action.select-rows":"Select from a table","action.delete-rows":"Delete rows","action.drop-table":"Drop table","action.add-index":"Add index","action.drop-index":"Drop index","action.drop-external-table":"Drop external table","menu.tables":"Tables","menu.topics":"Topics","menu.capture":"Change data capture","menu.replication":"Async replication","menu.users":"Users","action.create-topic":"Create Topic","action.drop-topic":"Drop Topic","action.alter-topic":"Alter Topic","action.create-cdc-stream":"Create changefeed","action.create-async-replication":"Create async replication","action.create-user":"Create user","action.create-group":"Create group","action.drop-user":"Drop user","action.drop-group":"Drop group","action.grant-privilege":"Grant privilege","action.revoke-privilege":"Revoke privilege","action.alter-async-replication":"Alter async replication","action.drop-async-replication":"Drop async replication"}'),zm=(0,$e.g4)("ydb-new-sql",{en:Lm});function Fm(){const e=(e=>{const t=t=>()=>{e(t())};return{createRowTable:t(dm),createColumnTable:t(um),createAsyncReplication:t(mm),alterAsyncReplication:t(Nm),dropAsyncReplication:t(Tm),alterTable:t(pm),selectQuery:t(hm),upsertQuery:t(vm),createExternalTable:t(ym),dropExternalTable:t(gm),createTopic:t(xm),alterTopic:t(bm),dropTopic:t(fm),createView:t(jm),dropTable:t(Mm),deleteRows:t(Dm),updateTable:t(Om),createUser:t(Im),createGroup:t(Pm),createCdcStream:t(Cm),grantPrivilege:t(Rm),revokePrivilege:t(km),dropUser:t(_m),dropGroup:t(Am),addTableIndex:t(Em),dropTableIndex:t(wm)}})(no(n.useCallback((e=>{cm(e)}),[]))),t=[{text:zm("menu.tables"),items:[{text:zm("action.create-row-table"),action:e.createRowTable},{text:zm("action.create-column-table"),action:e.createColumnTable},{text:zm("action.create-external-table"),action:e.createExternalTable},{text:zm("action.upsert-to-table"),action:e.upsertQuery},{text:zm("action.update-table"),action:e.updateTable},{text:zm("action.alter-table"),action:e.alterTable},{text:zm("action.select-rows"),action:e.selectQuery},{text:zm("action.delete-rows"),action:e.deleteRows},{text:zm("action.drop-table"),action:e.dropTable},{text:zm("action.drop-external-table"),action:e.dropExternalTable},{text:zm("action.add-index"),action:e.addTableIndex},{text:zm("action.drop-index"),action:e.dropTableIndex}]},{text:zm("menu.topics"),items:[{text:zm("action.create-topic"),action:e.createTopic},{text:zm("action.alter-topic"),action:e.alterTopic},{text:zm("action.drop-topic"),action:e.dropTopic}]},{text:zm("menu.replication"),items:[{text:zm("action.create-async-replication"),action:e.createAsyncReplication},{text:zm("action.alter-async-replication"),action:e.alterAsyncReplication},{text:zm("action.drop-async-replication"),action:e.dropAsyncReplication}]},{text:zm("menu.capture"),items:[{text:zm("action.create-cdc-stream"),action:e.createCdcStream}]},{text:zm("menu.users"),items:[{text:zm("action.create-user"),action:e.createUser},{text:zm("action.create-group"),action:e.createGroup},{text:zm("action.drop-user"),action:e.dropUser},{text:zm("action.drop-group"),action:e.dropGroup},{text:zm("action.grant-privilege"),action:e.grantPrivilege},{text:zm("action.revoke-privilege"),action:e.revokePrivilege}]}];return(0,d.jsx)(qi.r,{items:t,renderSwitcher:e=>(0,d.jsxs)(hn.$,{...e,children:[zm("button.new-sql"),(0,d.jsx)(hn.$.Icon,{children:(0,d.jsx)(lm.A,{})})]}),popupProps:{placement:"top"}})}const qm=(0,c.cn)("ydb-query-editor-controls"),Qm=({onClick:e,runIsLoading:t})=>{const{changedCurrentSettings:a,changedCurrentSettingsDescriptions:n}=wu(),r=a.length>0?{view:"outlined-info",selected:!0}:null;return(0,d.jsx)(sm.m,{disabled:0===a.length,content:(0,d.jsx)(om,{prefix:lu("gear.tooltip"),querySettings:n}),openDelay:0,placement:["top-start"],children:(0,d.jsxs)(hn.$,{onClick:e,loading:t,className:qm("gear-button"),...r,children:[(0,d.jsx)(ct.I,{data:nm.A,size:16}),r?(0,d.jsxs)("div",{className:qm("changed-settings"),children:["(",a.length,")"]}):null]})})},Um=({disabled:e,isLoading:t,highlightedAction:a,handleSendExecuteClick:n,onSettingsButtonClick:r,handleGetExplainQueryClick:s})=>{const i=(0,X.N4)(Ai.Wp),o="execute"===a?"action":void 0,l="explain"===a?"action":void 0,c=e||!i;return(0,d.jsxs)("div",{className:qm(),children:[(0,d.jsxs)("div",{className:qm("left"),children:[(0,d.jsxs)(hn.$,{onClick:()=>{n(i)},disabled:c,loading:t,view:o,className:qm("run-button"),children:[(0,d.jsx)(ct.I,{data:rm.A,size:14}),"Run"]}),(0,d.jsx)(hn.$,{onClick:()=>{s(i)},disabled:c,loading:t,view:l,children:"Explain"}),(0,d.jsx)(Qm,{onClick:r,runIsLoading:t})]}),(0,d.jsxs)("div",{className:qm("right"),children:[(0,d.jsx)(Fm,{}),(0,d.jsx)(Ji,{buttonProps:{disabled:e}})]})]})},Bm=(0,c.cn)("kv-divider");const $m=function(){return(0,d.jsx)("div",{className:Bm()})},Hm=(0,c.cn)("ydb-query-elapsed-time");function Gm({className:e}){const[,t]=n.useState({}),[a]=n.useState(Date.now()),r=Date.now()-a;n.useEffect((()=>{const e=setInterval((()=>{t({})}),Z.KF);return()=>{clearInterval(e)}}),[]);const s=r>Z.Jg*Z.KF?(0,nt.p0)(r).format("hh:mm:ss"):(0,nt.p0)(r).format("mm:ss");return(0,d.jsx)(Ct.J,{className:Hm(null,e),children:s})}var Wm=a(64280),Vm=a(80953);function Jm(e){var t;const a=(0,Nt.KH)(e);return"object"===typeof a&&"Query was cancelled"===(null===(t=a.error)||void 0===t?void 0:t.message)}const Ym=(0,c.cn)("kv-query-execution-status"),Km=()=>{const{isIndicatorShown:e,changedLastExecutionSettingsDescriptions:t}=wu();return e?(0,d.jsx)(sm.m,{openDelay:0,content:(0,d.jsx)(om,{prefix:lu("banner.query-settings.message"),querySettings:t}),children:(0,d.jsx)(ct.I,{data:ai.A,className:Ym("query-settings-icon")})}):null},Zm=({className:e,error:t,loading:a})=>{let n,r;if(a)n=(0,d.jsx)(Vm.t,{size:"xs"}),r="Running";else if((0,ee.F0)(t)&&"ECONNABORTED"===t.code)n=(0,d.jsx)(ct.I,{data:Wm.A}),r="Connection aborted";else if(Jm(t))n=(0,d.jsx)(ct.I,{data:st.A}),r="Stopped";else{const e=Boolean(t);n=(0,d.jsx)(ct.I,{data:e?ni.A:ti.A,className:Ym("result-status-icon",{error:e})}),r=e?"Failed":"Completed"}return(0,d.jsxs)("div",{className:Ym(null,e),children:[n,r,Jm(t)||a?null:(0,d.jsx)(Km,{})]})};var Xm=a(66528);const ep=H.F.injectEndpoints({endpoints:e=>({cancelQuery:e.mutation({queryFn:async({queryId:e,database:t},{signal:a})=>{try{const n=await window.api.viewer.sendQuery({database:t,action:"cancel-query",query_id:e},{signal:a});if((0,Nt.We)(n))return{error:n};return{data:(0,Nt.fW)(n)}}catch(n){return{error:n}}}})}),overrideExisting:"throw"}),tp=(0,c.cn)("cancel-query-button");function ap({queryId:e,tenantName:t}){const[a,r]=ep.useCancelQueryMutation(),s=n.useCallback((()=>{a({queryId:e,database:t})}),[e,a,t]);return(0,d.jsxs)(hn.$,{loading:r.isLoading,onClick:s,className:tp("stop-button",{error:Boolean(r.error)}),children:[(0,d.jsx)(ct.I,{data:Xm.A,size:16}),lu("action.stop")]})}const np=(0,c.cn)("ydb-query-duration"),rp=({duration:e})=>{if(!e)return null;const t=(0,vt.Bi)((0,vt.Jc)(e),1);return(0,d.jsx)("span",{className:np(),children:(0,d.jsx)(Ra,{className:np("item-with-popover"),contentClassName:np("popover-content"),text:t,popoverClassName:np("popover"),popoverContent:lu("query-duration.description"),buttonProps:{className:np("popover-button")}})})};var sp=a(55299);const ip=(0,c.cn)("ydb-query-settings-banner");function op(){const{isBannerShown:e,changedLastExecutionSettingsDescriptions:t,closeBanner:a}=wu();return e?(0,d.jsx)(sp.F,{className:ip(),theme:"info",align:"baseline",message:(0,d.jsx)(om,{prefix:lu("banner.query-settings.message"),querySettings:t}),onClose:a}):null}function lp(e){return e.replaceAll("\\","\\\\").replaceAll("\n","\\n").replaceAll("\r","\\r").replaceAll("\t","\\t")}var cp=a(6376);const dp=(0,c.cn)("ydb-query-ast"),up={automaticLayout:!0,selectOnLineNumbers:!0,readOnly:!0,minimap:{enabled:!1},wrappingIndent:"indent"};function mp({ast:e,theme:t}){return(0,d.jsx)("div",{className:dp(),children:(0,d.jsx)(cp.default,{language:"s-expression",value:e,options:up,theme:`vs-${t}`})})}var pp=a(73253);function hp(e){const t=n.useRef(null),a=n.useId(),{data:r,opts:s,shapes:i}=e;return n.useEffect((()=>{const e=t.current;if(!e)return;e.innerHTML="",e.style.setProperty("width","100vw"),e.style.setProperty("height","100vh");const a=(0,pp.og)(e.id,r,s,i);return a.render(),e.style.setProperty("width","100%"),e.style.setProperty("height","100%"),()=>{a.destroy()}}),[r,s,i]),(0,d.jsx)("div",{id:a,ref:t,style:{overflow:"auto"}})}const vp={renderNodeTitle:e=>{const t=e.name.split("|");return t.length>1?t[1]:e.name},textOverflow:"normal",initialZoomFitsCanvas:!0},gp={node:pp.SO};function yp(e){return(0,d.jsx)(hp,{...e,opts:vp,shapes:gp})}const xp=JSON.parse('{"description.graph-is-not-supported":"Graph can not be rendered","description.empty-result":"There is no {{activeSection}} for the request","action.result":"Result","action.stats":"Stats","action.schema":"Schema","action.explain-plan":"Explain Plan","action.json":"JSON","action.ast":"AST","action.copy":"Copy {{activeSection}}","trace":"Trace","title.truncated":"Truncated","title.result":"Result","tooltip_actions":"Actions","text_open-execution-plan":"Open Execution Plan","text_open-execution-plan_description":"New tab","text_download":"Download Execution Plan","text_download_description":"SVG","text_diagnostics":"Download Diagnostics","text_diagnostics_description":"JSON","text_error-plan-svg":"Error: {{error}}"}'),bp=(0,$e.g4)("ydb-execute-result",{en:xp}),fp=(0,c.cn)("ydb-query-result-stub-message");function jp({message:e}){return(0,d.jsx)("div",{className:fp(null),children:e})}const Sp=(0,c.cn)("ydb-query-explain-graph");function Tp({explain:e={},theme:t}){const{links:a,nodes:n}=e;return a&&n&&n.length?(0,d.jsx)("div",{className:Sp("canvas-container"),children:(0,d.jsx)(yp,{data:{links:a,nodes:n}},t)}):(0,d.jsx)(jp,{message:bp("description.graph-is-not-supported")})}var Np=a(7450);const Ep=(0,c.cn)("query-info-dropdown");var wp=a(112),Cp=a(92159);const Pp=H.F.injectEndpoints({endpoints:e=>({planToSvgQuery:e.query({queryFn:async({plan:e,database:t},{signal:a})=>{try{return{data:await window.api.viewer.planToSvg({database:t,plan:e},{signal:a})}}catch(n){return{error:n}}}})}),overrideExisting:"throw"}),Ip=JSON.parse('{"unknown-error":"An unknown error occurred"}'),Dp=(0,$e.g4)("ydb-errors",{en:Ip});function Ap(e,t){const a=document.createElement("a");a.href=e,a.download=t,document.body.appendChild(a),a.click(),document.body.removeChild(a)}function _p({title:e,description:t}){return(0,d.jsxs)("div",{className:Ep("menu-item-content"),children:[(0,d.jsx)(it.E,{variant:"body-1",children:e}),(0,d.jsx)(it.E,{variant:"body-1",color:"secondary",children:t})]})}function Rp({queryResultsInfo:e,database:t,hasPlanToSvg:a,error:r}){const[s,i]=n.useState(null),[o,{isLoading:l}]=Pp.useLazyPlanToSvgQueryQuery();n.useEffect((()=>()=>{s&&URL.revokeObjectURL(s)}),[s]);return{isLoading:l,items:n.useMemo((()=>{const n=[],l=e.plan;if(l&&a){const e=()=>s?Promise.resolve(s):o({plan:l,database:t}).unwrap().then((e=>{const t=new Blob([e],{type:"image/svg+xml"}),a=URL.createObjectURL(t);return i(a),a})).catch((e=>{const t=function(e){if("string"===typeof e)return e;if(!e)return Dp("unknown-error");if((0,ee.TX)(e))return e.message;if("object"===typeof e&&"data"in e){var t;const a=e;if(null!==(t=a.data)&&void 0!==t&&t.message)return a.data.message;if("string"===typeof a.data)return a.data}return e instanceof Error?e.message:JSON.stringify(e)}(e);return ht({title:bp("text_error-plan-svg",{error:t}),name:"plan-svg-error",type:"error"}),null})),a=()=>{e().then((e=>{e&&window.open(e,"_blank")}))},r=()=>{e().then((e=>{e&&Ap(e,"query-plan.svg")}))};n.push([{text:(0,d.jsx)(_p,{title:bp("text_open-execution-plan"),description:bp("text_open-execution-plan_description")}),icon:(0,d.jsx)(wp.A,{className:Ep("icon")}),action:a,className:Ep("menu-item")},{text:(0,d.jsx)(_p,{title:bp("text_download"),description:bp("text_download_description")}),icon:(0,d.jsx)(Cp.A,{className:Ep("icon")}),action:r,className:Ep("menu-item")}])}if(e){const a=()=>{const a=r?(0,Nt.KH)(r):void 0,n={...e,database:t,...a&&{error:a}},s=new Blob([JSON.stringify(n,null,2)],{type:"application/json"}),i=URL.createObjectURL(s);Ap(i,`query-diagnostics-${(new Date).getTime()}.json`),URL.revokeObjectURL(i)};n.push([{text:(0,d.jsx)(_p,{title:bp("text_diagnostics"),description:bp("text_diagnostics_description")}),icon:(0,d.jsx)(Cp.A,{className:Ep("icon")}),action:a,className:Ep("menu-item")}])}return n}),[e,a,s,o,t,r])}}function kp({queryResultsInfo:e,database:t,hasPlanToSvg:a,error:n}){const{isLoading:r,items:s}=Rp({queryResultsInfo:e,database:t,hasPlanToSvg:a,error:n});return s.length?(0,d.jsx)(qi.r,{popupProps:{placement:["bottom-end","left"]},switcherWrapperClassName:Ep("query-info-switcher-wrapper"),renderSwitcher:e=>(0,d.jsx)(lt.m,{title:bp("tooltip_actions"),children:(0,d.jsx)(hn.$,{view:"flat-secondary",loading:r,disabled:r,...e,children:(0,d.jsx)(hn.$.Icon,{children:(0,d.jsx)(Np.A,{})})})}),items:s,size:"xl"}):null}const Op=(0,c.cn)("ydb-query-json-viewer");function Mp({data:e}){return(0,d.jsx)("div",{className:Op("inspector"),children:(0,d.jsx)(jn,{data:e,isExpanded:()=>!0})})}var Lp=a(89954);const zp=(0,c.cn)("ydb-query-result-error ");function Fp({error:e}){const t=(0,Nt.KH)(e);return!t||Jm(e)?null:"object"===typeof t?(0,d.jsx)(Lp.O,{data:t}):(0,d.jsx)("div",{className:zp("message"),children:t})}const qp=(0,c.cn)("ydb-query-result-sets-viewer");function Qp({resultSets:e,selectedResultSet:t,setSelectedResultSet:a}){const n=(null===e||void 0===e?void 0:e.length)||0,r=null===e||void 0===e?void 0:e[t];return(0,d.jsxs)("div",{className:qp("result-wrapper"),children:[(()=>{if(n>1){const r=(0,Br._e)(n).map((t=>{var a;return{id:String(t),title:`Result #${t+1}${null!==e&&void 0!==e&&null!==(a=e[t])&&void 0!==a&&a.truncated?" (T)":""}`}}));return(0,d.jsx)("div",{children:(0,d.jsx)(ne.t,{className:qp("tabs"),size:"l",items:r,activeTab:String(t),onSelectTab:e=>a(Number(e))})})}return null})(),r?(0,d.jsxs)("div",{className:qp("result"),children:[(0,d.jsxs)("div",{className:qp("head"),children:[(0,d.jsx)(it.E,{variant:"subheader-3",children:null!==r&&void 0!==r&&r.truncated?bp("title.truncated"):bp("title.result")}),null!==r&&void 0!==r&&r.result?(0,d.jsx)(it.E,{color:"secondary",variant:"body-2",className:qp("row-count"),children:`(${null===r||void 0===r?void 0:r.result.length})`}):null]}),(0,d.jsx)(Xu,{data:r.result,columns:r.columns})]}):null]})}var Up=a(36590),Bp=a(79737),$p=a(79685);const Hp=(0,c.cn)("ydb-query-simplified-plan");function Gp({value:e,formatter:t}){if(!(0,$r.kf)(e))return;const a=t(Number(e));return(0,d.jsx)("div",{className:Hp("metrics-cell"),children:a})}var Wp=a(33705);const Vp={Table:"var(--g-color-text-info)",Predicate:"var(--g-color-text-positive)",Condition:"var(--g-color-text-utility)"};function Jp(e){return e in Vp?Vp[e]:"var(--g-color-text-secondary)"}function Yp(e={}){const t=[],a=Object.entries(e);if(1===a.length){const e=a[0][1],n=Jp(a[0][0]);t.push((0,d.jsx)("span",{style:{color:n},children:(0,he.vN)(e)},"param"))}else{const a=function(e){const t=[],{Table:a,Predicate:n,Condition:r,...s}=e;return a&&t.push(["Table",a]),n&&t.push(["Predicate",n]),r&&t.push(["Condition",r]),t.concat(Object.entries(s))}(e);for(let e=0;e0&&t.push(", "),t.push((0,d.jsxs)("span",{style:{color:s},children:[n,": ",(0,he.vN)(r)]},e))}}return t}function Kp({params:e}){return e?(0,d.jsxs)("span",{className:Hp("operation-params"),children:["(",Yp(e),")"]}):null}function Zp({modifiers:e,left:t}){return(0,d.jsx)("div",{className:Hp("divider",e),style:{left:t}})}function Xp({row:e,depth:t=0,params:a}){const{name:r,operationParams:s,lines:i=""}=a,o=e.getLeafRows().length>0&&e.getIsExpanded(),l=n.useMemo((()=>function(e,t){const a=e.split(".").map(Number),n=[];for(let r=0;re<1e8?(0,$p.p)(e).format():(0,$r.z0)(e,1)})}const th=[{accessorKey:"name",accessorFn:function(e){return{name:e.name,operationParams:e.operationParams,lines:e.lines}},header:()=>(0,d.jsx)(Bp.A,{children:"Operation"}),size:600,cell:e=>(0,d.jsx)(Xp,{row:e.row,depth:e.row.depth,params:e.getValue()})},{accessorKey:"aCpu",header:()=>(0,d.jsx)(Bp.A,{children:"A-Cpu"}),size:90,minSize:90,cell:function(e){return(0,d.jsx)(Gp,{value:e.getValue(),formatter:e=>(0,vt.Xo)(Math.round(e))})},meta:{align:"right",verticalAlign:"top"}},{accessorKey:"aRows",header:()=>(0,d.jsx)(Bp.A,{children:"A-Rows"}),size:90,minSize:90,cell:eh,meta:{align:"right",verticalAlign:"top"}},{accessorKey:"eCost",header:()=>(0,d.jsx)(Bp.A,{children:"E-Cost"}),size:90,minSize:90,cell:eh,meta:{align:"right",verticalAlign:"top"}},{accessorKey:"eRows",header:()=>(0,d.jsx)(Bp.A,{children:"E-Rows"}),size:90,minSize:90,cell:eh,meta:{align:"right",verticalAlign:"top"}},{accessorKey:"eSize",header:()=>(0,d.jsx)(Bp.A,{children:"E-Size"}),size:90,minSize:90,cell:eh,meta:{align:"right",verticalAlign:"top"}}];function ah({plan:e}){const t=n.useMemo((()=>function(e,t=""){if(!e)return[];const a=[{items:e,prefix:t,parentIndex:-1,parentArray:[]}],n=[];for(;a.length>0;){const{items:e,prefix:t,parentIndex:r,parentArray:s}=a.pop(),i=[];for(let n=0;ne.children,enableExpanding:!0,onExpandedChange:r,state:{expanded:a},enableColumnResizing:!0,columnResizeMode:"onChange"});return(0,d.jsx)(Bp.X,{wrapperClassName:Hp(),table:s,stickyHeader:!0,width:"max"})}const nh=H.F.injectEndpoints({endpoints:e=>({checkTrace:e.query({queryFn:async({url:e},{signal:t,dispatch:a})=>{try{const n=await window.api.trace.checkTrace({url:e},{signal:t});return a((0,Ai.P7)()),{data:n}}catch(n){return{error:n}}}})}),overrideExisting:"throw"});function rh(e,t){return e.replace(/\${(\w+)}/g,((e,a)=>t[a]||e))}function sh({traceId:e,isTraceReady:t}){const{traceCheck:a,traceView:r}=(0,Ps.Zd)(),s=null!==a&&void 0!==a&&a.url?rh(a.url,{traceId:e}):"",i=null!==r&&void 0!==r&&r.url?rh(r.url,{traceId:e}):"",[o,{isLoading:l,isUninitialized:c}]=nh.useLazyCheckTraceQuery();return n.useEffect((()=>{let e;return s&&!t&&(e=o({url:s})),()=>{var t;return null===(t=e)||void 0===t?void 0:t.abort()}}),[o,s,t]),!i||c&&!t?null:(0,d.jsxs)(hn.$,{view:l?"flat-secondary":"flat-info",loading:l,href:i,target:"_blank",children:[bp("trace"),(0,d.jsx)(hn.$.Icon,{children:(0,d.jsx)(wp.A,{})})]})}const ih=(0,c.cn)("ydb-query-result"),oh="result",lh="schema",ch="simplified",dh="json",uh="stats",mh="ast",ph={get result(){return bp("action.result")},get schema(){return bp("action.schema")},get simplified(){return bp("action.explain-plan")},get json(){return bp("action.json")},get stats(){return bp("action.stats")},get ast(){return bp("action.ast")}},hh=["result","schema","simplified","stats"],vh=["schema","json","simplified","ast"];function gh({result:e,resultType:t="execute",isResultsCollapsed:a,theme:r,tenantName:s,queryText:i,onCollapseResults:l,onExpandResults:c}){const u=(0,X.YQ)(),m="execute"===t,p="explain"===t,[h,v]=n.useState(0),[g,y]=n.useState((()=>m?oh:lh)),[x]=(0,X.iK)(Z.lr),{error:b,isLoading:f,queryId:j,data:S={}}=e,{preparedPlan:T,simplifiedPlan:N,stats:E,resultSets:w,ast:C}=S;n.useEffect((()=>{"execute"!==t||hh.includes(g)||y("result"),"explain"!==t||vh.includes(g)||y("schema")}),[g,t]);const P=n.useMemo((()=>{let e=[];return m?e=hh:p&&(e=vh),e.map((e=>({value:e,content:ph[e]})))}),[m,p]);n.useEffect((()=>()=>{u((0,Ou.sM)())}),[u]);const I=e=>{y(e)},D=()=>{switch(g){case oh:{var e;const t=null===S||void 0===S||null===(e=S.resultSets)||void 0===e?void 0:e[h],a=function(e){if(null===e||void 0===e||!e.length)return"";const t=Object.keys(e[0]),a=[t.map(lp).join("\t")];for(const n of e){const e=[];for(const a of t){const t=n[a];e.push(lp("object"===typeof t?JSON.stringify(t):`${t}`))}a.push(e.join("\t"))}return a.join("\n")}(null===t||void 0===t?void 0:t.result);return a}case dh:return null===T||void 0===T?void 0:T.pristine;case ch:return null===N||void 0===N?void 0:N.pristine;case uh:return E;case mh:return C;default:return}},A=()=>{const e=D(),t=(0,he.vN)(e);return t?(0,d.jsx)(mn.b,{text:t,view:"flat-secondary",title:bp("action.copy",{activeSection:g})}):null},_=()=>(0,d.jsx)(jp,{message:bp("description.empty-result",{activeSection:ph[g]})});return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)("div",{className:ih("controls"),children:[(0,d.jsxs)("div",{className:ih("controls-left"),children:[(0,d.jsx)(Zm,{error:b,loading:f}),!b&&!f&&(0,d.jsxs)(n.Fragment,{children:[(0,Br.f8)(null===E||void 0===E?void 0:E.DurationUs)?(0,d.jsx)(rp,{duration:Number(E.DurationUs)}):null,P.length&&g?(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)($m,{}),(0,d.jsx)(Pd.a,{options:P,value:g,onUpdate:I})]}):null]}),f?(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Gm,{className:ih("elapsed-time")}),(0,d.jsx)(ap,{queryId:j,tenantName:s})]}):null,null!==S&&void 0!==S&&S.traceId&&m?(0,d.jsx)(sh,{traceId:S.traceId,isTraceReady:e.isTraceReady}):null]}),(0,d.jsxs)("div",{className:ih("controls-right"),children:[f||Jm(b)?null:(0,d.jsx)(kp,{queryResultsInfo:{queryText:i,ast:S.ast,stats:S.stats,plan:S.plan},error:b,database:s,hasPlanToSvg:Boolean((null===S||void 0===S?void 0:S.plan)&&x&&m)}),A(),(0,d.jsx)(Mu,{}),(0,d.jsx)(Ru,{onCollapse:l,onExpand:c,isCollapsed:a,initialDirection:"bottom"})]})]}),f||Jm(b)?null:(0,d.jsx)(op,{}),(0,d.jsx)(o.r,{loading:f,children:(0,d.jsx)($u,{className:ih("result"),children:(()=>{return b?(0,d.jsx)(Fp,{error:b}):g===oh?(0,d.jsx)(Qp,{resultSets:w,selectedResultSet:h,setSelectedResultSet:v}):g===lh?null!==T&&void 0!==T&&null!==(e=T.nodes)&&void 0!==e&&e.length?(0,d.jsx)(Tp,{theme:r,explain:T}):_():g===dh?null!==T&&void 0!==T&&T.pristine?(0,d.jsx)(Mp,{data:null===T||void 0===T?void 0:T.pristine}):_():g===ch?null!==N&&void 0!==N&&null!==(t=N.plan)&&void 0!==t&&t.length?(0,d.jsx)(ah,{plan:N.plan}):_():g===uh?E?(0,d.jsx)(Mp,{data:E}):_():g===mh?C?(0,d.jsx)(mp,{ast:C,theme:r}):_():null;var e,t})()})})]})}var yh=a(16122),xh=a(23971);const bh=()=>-1,fh=(0,c.cn)("ydb-query-settings-select");function jh(e){return(0,d.jsx)("div",{className:fh("selector"),children:(0,d.jsx)(le.l,{id:e.id,disabled:e.disabled,options:e.settingOptions,value:[e.setting],onUpdate:t=>{e.onUpdateSetting(t[0])},getOptionHeight:bh,popupClassName:fh("popup"),renderOption:e=>(0,d.jsxs)("div",{className:fh("item",{type:e.value}),children:[(0,d.jsxs)("div",{className:fh("item-title"),children:[e.content,e.isDefault?gu("description.default"):""]}),e.text&&(0,d.jsx)("span",{className:fh("item-description"),children:e.text})]}),width:"max"})})}const Sh=(0,c.cn)("ydb-query-settings-dialog");function Th(){const e=(0,X.YQ)(),t=(0,X.N4)(Ui.xM),[a,r]=(0,X.XS)(),s=n.useCallback((()=>{e((0,Ui.NJ)("idle"))}),[e]),i=n.useCallback((e=>{r(e),s()}),[s,r]);return(0,d.jsxs)(Ri.l,{open:"settings"===t,size:"s",onClose:s,className:Sh(),hasCloseButton:!1,children:[(0,d.jsx)(Ri.l.Header,{caption:gu("action.settings")}),(0,d.jsx)(Nh,{initialValues:a,onSubmit:i,onClose:s})]})}function Nh({initialValues:e,onSubmit:t,onClose:a}){const{control:r,handleSubmit:s,formState:{errors:i}}=(0,xh.mN)({defaultValues:e,resolver:(0,yh.u)(Nt.id)}),[o]=(0,X.iK)(Z.lr),l=(0,ie.Oi)();return(0,d.jsxs)("form",{onSubmit:s(t),children:[(0,d.jsxs)(Ri.l.Body,{className:Sh("dialog-body"),children:[(0,d.jsxs)(ot.s,{direction:"row",alignItems:"flex-start",className:Sh("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"queryMode",className:Sh("field-title"),children:ju.queryMode.title}),(0,d.jsx)("div",{className:Sh("control-wrapper",{queryMode:!0}),children:(0,d.jsx)(xh.xI,{name:"queryMode",control:r,render:({field:e})=>(0,d.jsx)(jh,{id:"queryMode",setting:e.value,onUpdateSetting:e.onChange,settingOptions:ju.queryMode.options})})})]}),(0,d.jsxs)(ot.s,{direction:"row",alignItems:"flex-start",className:Sh("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"timeout",className:Sh("field-title"),children:ju.timeout.title}),(0,d.jsx)("div",{className:Sh("control-wrapper"),children:(0,d.jsx)(xh.xI,{name:"timeout",control:r,render:({field:e})=>{var t,a;return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Qi.k,{id:"timeout",type:"number",...e,value:null===(t=e.value)||void 0===t?void 0:t.toString(),className:Sh("timeout"),placeholder:"60",validationState:i.timeout?"invalid":void 0,errorMessage:null===(a=i.timeout)||void 0===a?void 0:a.message,errorPlacement:"inside"}),(0,d.jsx)("span",{className:Sh("timeout-suffix"),children:gu("form.timeout.seconds")})]})}})})]}),l&&(0,d.jsxs)(ot.s,{direction:"row",alignItems:"flex-start",className:Sh("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"tracingLevel",className:Sh("field-title"),children:ju.tracingLevel.title}),(0,d.jsx)("div",{className:Sh("control-wrapper"),children:(0,d.jsx)(xh.xI,{name:"tracingLevel",control:r,render:({field:e})=>(0,d.jsx)(jh,{id:"tracingLevel",setting:e.value,onUpdateSetting:e.onChange,settingOptions:ju.tracingLevel.options})})})]}),(0,d.jsxs)(ot.s,{direction:"row",alignItems:"flex-start",className:Sh("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"transactionMode",className:Sh("field-title"),children:ju.transactionMode.title}),(0,d.jsx)("div",{className:Sh("control-wrapper",{transactionMode:!0}),children:(0,d.jsx)(xh.xI,{name:"transactionMode",control:r,render:({field:e})=>(0,d.jsx)(jh,{id:"transactionMode",setting:e.value,onUpdateSetting:e.onChange,settingOptions:ju.transactionMode.options})})})]}),(0,d.jsxs)(ot.s,{direction:"row",alignItems:"flex-start",className:Sh("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"statisticsMode",className:Sh("field-title"),children:ju.statisticsMode.title}),(0,d.jsx)(sm.m,{className:Sh("statistics-mode-tooltip"),disabled:!o,openDelay:0,content:gu("tooltip_plan-to-svg-statistics"),children:(0,d.jsx)("div",{className:Sh("control-wrapper",{statisticsMode:!0}),children:(0,d.jsx)(xh.xI,{name:"statisticsMode",control:r,render:({field:e})=>(0,d.jsx)(jh,{id:"statisticsMode",disabled:o,setting:e.value,onUpdateSetting:e.onChange,settingOptions:ju.statisticsMode.options})})})})]}),(0,d.jsxs)(ot.s,{direction:"row",alignItems:"flex-start",className:Sh("dialog-row"),children:[(0,d.jsx)("label",{htmlFor:"limitRows",className:Sh("field-title"),children:ju.limitRows.title}),(0,d.jsx)("div",{className:Sh("control-wrapper"),children:(0,d.jsx)(xh.xI,{name:"limitRows",control:r,render:({field:e})=>{var t,a;return(0,d.jsx)(Qi.k,{id:"limitRows",type:"number",...e,value:null===(t=e.value)||void 0===t?void 0:t.toString(),className:Sh("limit-rows"),placeholder:"10000",validationState:i.limitRows?"invalid":void 0,errorMessage:null===(a=i.limitRows)||void 0===a?void 0:a.message,errorPlacement:"inside"})}})})]})]}),(0,d.jsx)(Ri.l.Footer,{textButtonApply:gu("button-done"),textButtonCancel:gu("button-cancel"),onClickButtonCancel:a,propsButtonApply:{type:"submit"},renderButtons:(e,t)=>(0,d.jsxs)("div",{className:Sh("buttons-container"),children:[(0,d.jsx)(Bo.N,{href:"https://ydb.tech/docs",target:"_blank",className:Sh("documentation-link"),children:gu("docs")}),(0,d.jsxs)("div",{className:Sh("main-buttons"),children:[t,e]})]})})]})}const Eh=(0,a(99006)._)((async()=>({Editor:(await Promise.resolve().then(a.bind(a,6376))).default})),"Editor");var wh=a(41614),Ch=a(67913);const Ph=JSON.parse('{"context_syntax-error":"Syntax error"}'),Ih=(0,$e.g4)("ydb-monaco",{en:Ph}),Dh=(0,uu.debounce)((function(){var e;const t=null===(e=window.ydbEditor)||void 0===e?void 0:e.getModel();if(!t)return void console.error("unable to retrieve model when highlighting errors");const a=(0,wh.kh)(t.getValue()).errors;if(!a.length)return void _h();const n=a.map((e=>({message:Ih("context_syntax-error"),source:e.message,severity:Ch.cj.Error,startLineNumber:e.startLine,startColumn:e.startColumn+1,endLineNumber:e.endLine,endColumn:e.endColumn+1})));Ch.EN.setModelMarkers(t,"ydb",n)}),500);function Ah(){const e=(t=Dh,n.useEffect((()=>()=>{t.cancel()}),[t]),t);var t;return n.useCallback((()=>{_h(),e()}),[e])}function _h(){Ch.EN.removeAllMarkers("ydb")}const Rh={automaticLayout:!0,selectOnLineNumbers:!0,minimap:{enabled:!1},fixedOverflowWidgets:!0};const kh="navigation";function Oh({changeUserInput:e,theme:t,handleSendExecuteClick:a,handleGetExplainQueryClick:r}){const s=(0,X.N4)(Ai.Wp),i=(0,X.YQ)(),o=(0,X.N4)(Ai.py),l=function(){const[e]=(0,X.iK)(Z.LK),[t]=(0,X.iK)(Z.IO);return n.useMemo((()=>{const a=Boolean(e);return{quickSuggestions:a,suggestOnTriggerCharacters:a,acceptSuggestionOnEnter:t?"on":"off",...Rh}}),[e,t])}(),c=Ah(),[u]=(0,X.iK)(Z.zk),m=(0,X.A5)((()=>o&&0!==o.length?o[o.length-1].queryText:"")),p=(0,X.A5)((()=>{u===Nt.x5.explain?r(s):a(s)}));return(0,d.jsx)(Eh,{language:"yql",value:s,options:l,onChange:t=>{c(),e({input:t})},editorDidMount:(e,t)=>{window.ydbEditor=e;const n=function(e){const{KeyMod:t,KeyCode:a}=e,n=t.CtrlCmd;return{sendQuery:n|a.Enter,sendSelectedQuery:n|t.Shift|e.KeyCode.Enter,selectPreviousQuery:n|a.UpArrow,selectNextQuery:n|a.DownArrow,saveQuery:n|a.KeyS,saveSelectedQuery:n|t.Shift|a.KeyS}}(t);t.editor.registerCommand("insertSnippetToEditor",((t,a)=>{const n=e.getContribution("snippetController2");n&&(e.focus(),e.setValue(""),n.insert(a))})),function(e){const t=ge()((()=>{e.layout()}),100);e.layout(),window.addEventListener("resize",t),e.onDidDispose((()=>{window.removeEventListener("resize",t)}))}(e),function(e,t){Mh(e.getValue(),t()),e.onDidChangeModelContent((()=>{Mh(e.getValue(),t())})),e.onDidDispose((()=>{window.onbeforeunload=null}))}(e,m),e.focus(),e.addAction({id:"sendQuery",label:lu("action.send-query"),keybindings:[n.sendQuery],precondition:void 0,keybindingContext:void 0,contextMenuGroupId:kh,contextMenuOrder:1,run:()=>p()});const r=e.createContextKey("canSendSelectedText",!1);e.onDidChangeCursorSelection((({selection:e,secondarySelections:t})=>{const a=e.selectionStartLineNumber!==e.positionLineNumber||e.selectionStartColumn!==e.positionColumn,n=t.length>0;r.set(a&&!n)})),e.addAction({id:"sendSelectedQuery",label:lu("action.send-selected-query"),keybindings:[n.sendSelectedQuery],precondition:"canSendSelectedText",contextMenuGroupId:kh,contextMenuOrder:1,run:e=>{const t=e.getSelection(),n=e.getModel();if(t&&n){const e=n.getValueInRange({startLineNumber:t.getSelectionStart().lineNumber,startColumn:t.getSelectionStart().column,endLineNumber:t.getPosition().lineNumber,endColumn:t.getPosition().column});a(e,!0)}}}),e.addAction({id:"previous-query",label:lu("action.previous-query"),keybindings:[n.selectPreviousQuery],contextMenuGroupId:kh,contextMenuOrder:2,run:()=>{i((0,Ai.JK)())}}),e.addAction({id:"next-query",label:lu("action.next-query"),keybindings:[n.selectNextQuery],contextMenuGroupId:kh,contextMenuOrder:3,run:()=>{i((0,Ai.tS)())}}),e.addAction({id:"save-query",label:lu("action.save-query"),keybindings:[n.saveQuery],run:()=>{_i.Ay.show(Ki)}})},theme:`vs-${t}`,editorWillUnmount:()=>{window.ydbEditor=void 0}})}function Mh(e,t){const a=!!e&&e!==t;window.onbeforeunload=a?e=>{e.preventDefault(),e.returnValue=""}:null}const Lh=(0,c.cn)("query-editor"),zh={triggerExpand:!1,triggerCollapse:!1,collapsed:!0};function Fh(e){const t=(0,X.YQ)(),{tenantName:a,path:r,type:s,theme:i,changeUserInput:o}=e,l=(0,X.N4)(Ai.yJ),c=(0,X.N4)(Ai.wf),u=(0,X.N4)(Ai.py),m=(0,X.N4)(Ai.Kz),p=(0,X.N4)(K.Ab),v=Boolean(c),[g]=(0,X.XS)(),y=(0,ie.Oi)(),[x,b]=Nu(),{resetBanner:f}=wu(),[j,S]=(0,X.iK)(Z.zk),[T,N]=n.useState(""),[E]=Ai.JO.useUseSendQueryMutation();n.useEffect((()=>{l!==a&&t((0,Ai.Id)(a))}),[t,a,l]);const[w,C]=n.useReducer(Au(Z.GV),zh);n.useEffect((()=>{C(Pu.triggerCollapse)}),[]),n.useEffect((()=>{C(p||v?Pu.triggerExpand:Pu.triggerCollapse)}),[p,v]);const P=(0,X.A5)(((e,n)=>{S(Nt.x5.execute),N(e),(0,uu.isEqual)(x,g)||(f(),b(g));const r=(0,mu.A)();var s;(E({actionType:"execute",query:e,database:a,querySettings:g,enableTracingLevel:y,queryId:r}),t((0,K.o)(!1)),n)||e!==(null===(s=u[m])||void 0===s?void 0:s.queryText)&&t((0,Ai.nO)({queryText:e,queryId:r}));C(Pu.triggerExpand)})),I=()=>{t((0,Ui.NJ)("settings"))},D=(0,X.A5)((e=>{S(Nt.x5.explain),N(e),(0,uu.isEqual)(x,g)||(f(),b(g));const n=(0,mu.A)();E({actionType:"explain",query:e,database:a,querySettings:g,enableTracingLevel:y,queryId:n}),t((0,K.o)(!1)),C(Pu.triggerExpand)}));return(0,d.jsxs)("div",{className:Lh(),children:[(0,d.jsxs)(h,{direction:"vertical",defaultSizePaneKey:Z.l_,triggerCollapse:w.triggerCollapse,triggerExpand:w.triggerExpand,minSize:[0,52],collapsedSizes:[100,0],onSplitStartDragAdditional:()=>{C(Pu.clear)},children:[(0,d.jsxs)("div",{className:Lh("pane-wrapper",{top:!0}),children:[(0,d.jsx)("div",{className:Lh("monaco-wrapper"),children:(0,d.jsx)("div",{className:Lh("monaco"),children:(0,d.jsx)(Oh,{changeUserInput:o,theme:i,handleSendExecuteClick:P,handleGetExplainQueryClick:D})})}),(0,d.jsx)(Um,{handleSendExecuteClick:P,onSettingsButtonClick:I,isLoading:Boolean(null===c||void 0===c?void 0:c.isLoading),handleGetExplainQueryClick:D,highlightedAction:j})]}),(0,d.jsx)("div",{className:Lh("pane-wrapper"),children:(0,d.jsx)(qh,{resultVisibilityState:w,onExpandResultHandler:()=>{C(Pu.triggerExpand)},onCollapseResultHandler:()=>{C(Pu.triggerCollapse)},type:s,theme:i,result:c,tenantName:a,path:r,showPreview:p,queryText:T},null===c||void 0===c?void 0:c.queryId)})]}),(0,d.jsx)(Th,{})]})}function qh({resultVisibilityState:e,onExpandResultHandler:t,onCollapseResultHandler:a,type:n,theme:r,result:s,tenantName:i,path:o,showPreview:l,queryText:c}){return l?(0,d.jsx)(am,{database:i,path:o,type:n}):s?(0,d.jsx)(gh,{result:s,resultType:null===s||void 0===s?void 0:s.type,theme:r,tenantName:i,isResultsCollapsed:e.collapsed,onExpandResults:t,onCollapseResults:a,queryText:c}):null}const Qh=[{id:ae.tQ.newQuery,title:lu("tabs.newQuery")},{id:ae.tQ.history,title:lu("tabs.history")},{id:ae.tQ.saved,title:lu("tabs.saved")}],Uh=({className:e,activeTab:t})=>{const a=(0,Xn.zy)(),n=(0,ye.mA)(a);return(0,d.jsx)("div",{className:e,children:(0,d.jsx)(ne.t,{size:"l",allowNotSelected:!0,activeTab:t,items:Qh,wrapTo:({id:e},t)=>{const a=(0,na.YL)({...n,[na.vh.queryTab]:e});return(0,d.jsx)(wi.E,{to:a,children:t},e)}})})};var Bh=a(65872),$h=a(64470);const Hh=(0,c.cn)("ydb-saved-queries"),Gh=({visible:e,queryName:t,onCancelClick:a,onConfirmClick:n})=>(0,d.jsxs)(Ri.l,{open:e,hasCloseButton:!1,size:"s",onClose:a,onEnterKeyDown:n,children:[(0,d.jsx)(Ri.l.Header,{caption:lu("delete-dialog.header")}),(0,d.jsxs)(Ri.l.Body,{className:Hh("dialog-body"),children:[lu("delete-dialog.question"),(0,d.jsx)("span",{className:Hh("dialog-query-name"),children:` ${t}?`})]}),(0,d.jsx)(Ri.l.Footer,{textButtonApply:lu("delete-dialog.delete"),textButtonCancel:lu("delete-dialog.cancel"),onClickButtonCancel:a,onClickButtonApply:n})]}),Wh=({changeUserInput:e})=>{const t=Bi(),a=(0,X.YQ)(),r=(0,X.N4)(Ui.cu),[s,i]=n.useState(!1),[o,l]=n.useState(""),c=()=>{i(!1),l("")},u=no(n.useCallback((({queryText:t,queryName:n})=>{e({input:t}),a((0,Ui.JP)(n)),a((0,oe.sH)(ae.tQ.newQuery))}),[e,a])),m=[{name:"name",header:"Name",render:({row:e})=>(0,d.jsx)("div",{className:Hh("query-name"),children:e.name}),width:200},{name:"body",header:"Query Text",render:({row:e})=>{return(0,d.jsxs)("div",{className:Hh("query"),children:[(0,d.jsx)("div",{className:Hh("query-body"),children:(0,d.jsx)(so,{value:e.body,maxQueryHeight:6})}),(0,d.jsxs)("span",{className:Hh("controls"),children:[(0,d.jsx)(hn.$,{view:"flat-secondary",children:(0,d.jsx)(ct.I,{data:Bh.A})}),(0,d.jsx)(hn.$,{view:"flat-secondary",onClick:(t=e.name,e=>{e.stopPropagation(),i(!0),l(t)}),children:(0,d.jsx)(ct.I,{data:$h.A})})]})]});var t},sortable:!1,resizeMinWidth:650}];return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsxs)(qe.L,{className:Hh(),children:[(0,d.jsx)(qe.L.Controls,{children:(0,d.jsx)(Be.v,{onChange:e=>{a((0,Ui.ys)(e))},placeholder:lu("filter.text.placeholder"),className:Hh("search")})}),(0,d.jsx)(qe.L.Table,{children:(0,d.jsx)(Fe.l,{columnsWidthLSKey:"savedQueriesTableColumnsWidth",columns:m,data:t,settings:lo,emptyDataMessage:lu(r?"history.empty-search":"saved.empty"),rowClassName:()=>Hh("row"),onRowClick:e=>u({queryText:e.body,queryName:e.name}),initialSortOrder:{columnId:"name",order:Rt.Ay.ASCENDING}})})]}),(0,d.jsx)(Gh,{visible:s,queryName:o,onCancelClick:()=>{c()},onConfirmClick:()=>{c(),a((0,Ui.fu)(o)),l("")}})]})},Vh=(0,c.cn)("ydb-query"),Jh=e=>{const t=(0,X.YQ)(),{queryTab:a=ae.tQ.newQuery}=(0,X.N4)((e=>e.tenant)),s=e=>{t((0,Ai.iZ)(e))},i=n.useMemo((()=>Qh.find((({id:e})=>e===a))),[a]);return(0,d.jsxs)("div",{className:Vh(),children:[i?(0,d.jsx)(r.mg,{children:(0,d.jsx)("title",{children:i.title})}):null,(0,d.jsx)(Uh,{className:Vh("tabs"),activeTab:a}),(0,d.jsx)("div",{className:Vh("content"),children:(()=>{switch(a){case ae.tQ.newQuery:return(0,d.jsx)(Fh,{changeUserInput:s,...e});case ae.tQ.history:return(0,d.jsx)(du,{changeUserInput:s});case ae.tQ.saved:return(0,d.jsx)(Wh,{changeUserInput:s});default:return null}})()})]})};var Yh=a(46649),Kh=a(93844);const Zh=["query","diagnostics"],Xh={query:Yh.A,diagnostics:Kh.A};const ev=(0,c.cn)("ydb-tenant-navigation"),tv=({id:e,title:t,icon:a})=>({value:e,content:(0,d.jsxs)("span",{className:ev("item"),children:[(0,d.jsx)(ct.I,{data:a,size:16,className:ev("icon")}),(0,d.jsx)("span",{className:ev("text"),children:t})]})}),av=()=>{const e=function(){const e=(0,Xn.W6)(),t=(0,Xn.zy)(),a=(0,ye.mA)(t),[,r]=(0,X.iK)(Z.Mt),{tenantPage:s}=(0,X.N4)((e=>e.tenant)),i=n.useMemo((()=>{if(t.pathname!==ye.Ay.tenant)return[];const n=Zh.map((t=>{const n=ae.Dg[t],i=(0,na.YL)({...a,[ae.Dt]:n});return{id:n,title:Lr(`pages.${t}`),icon:Xh[t],path:i,current:s===n,onForward:()=>{r(n),e.push(i)}}}));return n}),[s,r,t.pathname,e,a]);return i}();return(0,d.jsx)("div",{className:ev(),children:(0,d.jsx)(Pd.a,{width:"auto",onUpdate:t=>{const a=e.find((e=>e.id===t));null===a||void 0===a||a.onForward()},size:"l",className:ev("body"),value:(e.find((e=>e.current))||e[0]).id,options:e.map(tv)})})},nv=(0,c.cn)("object-general");const rv=function(e){const t=(0,te.i)(),{tenantPage:a}=(0,X.N4)((e=>e.tenant));return(0,d.jsxs)("div",{className:nv(),children:[(0,d.jsx)(av,{}),(()=>{const{type:n,additionalTenantProps:r,additionalNodesProps:s,tenantName:i,path:o}=e;return a===ae.Dg.query?(0,d.jsx)(Jh,{tenantName:i,path:o,theme:t,type:n}):(0,d.jsx)(iu,{type:n,tenantName:i,path:o,additionalTenantProps:r,additionalNodesProps:s})})()]})};var sv=a(40336),iv=a(1956);const ov=H.F.injectEndpoints({endpoints:e=>({getSchemaAcl:e.query({queryFn:async({path:e,database:t},{signal:a})=>{try{const n=await window.api.viewer.getSchemaAcl({path:e,database:t},{signal:a});return{data:{acl:n.Common.ACL,effectiveAcl:n.Common.EffectiveACL,owner:n.Common.Owner,interruptInheritance:n.Common.InterruptInheritance}}}catch(n){return{error:n}}},providesTags:["All"]})}),overrideExisting:"throw"}),lv=JSON.parse('{"title_rights":"Access Rights","title_effective-rights":"Effective Access Rights","title_owner":"Owner","title_interupt-inheritance":"Interrupt inheritance","description_empty":"No Acl data"}'),cv=(0,$e.g4)("ydb-acl",{en:lv}),dv=(0,c.cn)("ydb-acl"),uv=["access","type","inheritance"],mv={access:"Access",type:"Access type",inheritance:"Inheritance type"},pv=new Set(["Object","Container"]);function hv({value:e}){const t="string"===typeof e?[e]:e;return(0,d.jsx)("div",{className:dv("definition-content"),children:t.map((e=>(0,d.jsx)("span",{children:e},e)))})}function vv(e){if(!e||!e.length)return[];const t=function(e){return e.map((e=>{const{AccessRules:t=[],AccessRights:a=[],AccessType:n,InheritanceType:r,Subject:s}=e,i=t.concat(a),o="Allow"===n?void 0:n;let l;return((null===r||void 0===r?void 0:r.length)!==pv.size||r.some((e=>!pv.has(e))))&&(l=r),{access:i.length?i:void 0,type:o,inheritance:l,Subject:s}}))}(e);return t.map((({Subject:e,...t})=>{const a=Object.entries(t).filter((([e,t])=>Boolean(t)));return 1===a.length&&"access"===a[0][0]?{name:e,content:(0,d.jsx)(hv,{value:a[0][1]}),multilineName:!0}:{label:(0,d.jsx)("span",{className:dv("group-label"),children:e}),items:uv.map((e=>{const a=t[e];if(a)return{name:mv[e],content:(0,d.jsx)(hv,{value:a}),multilineName:!0}})).filter(Br.f8)}}))}const gv=({path:e,database:t})=>{const{currentData:a,isFetching:r,error:s}=ov.useGetSchemaAclQuery({path:e,database:t}),i=r&&!a,{acl:o,effectiveAcl:l,owner:c,interruptInheritance:u}=a||{},m=vv(o),p=vv(l),h=function(e){const t=(a=e,a&&a.endsWith("@staff")&&!a.startsWith("svc_")?a.split("@")[0]:a);var a;return t?[{name:t,content:cv("title_owner"),multilineName:!0}]:[]}(c),v=u?[{name:cv("title_interupt-inheritance"),content:(0,d.jsx)(ct.I,{data:iv.A,size:20}),multilineName:!0}]:[];if(i)return(0,d.jsx)(ue.a,{});if(s)return(0,d.jsx)(de.o,{error:s});if(!o&&!c&&!l)return(0,d.jsx)(n.Fragment,{children:cv("description_empty")});const g=h.concat(m);return(0,d.jsxs)("div",{className:dv(),children:[(0,d.jsx)(yv,{items:v}),(0,d.jsx)(yv,{items:g,title:cv("title_rights")}),(0,d.jsx)(yv,{items:p,title:cv("title_effective-rights")})]})};function yv({items:e,title:t}){return e.length?(0,d.jsxs)(n.Fragment,{children:[t&&(0,d.jsx)("div",{className:dv("list-title"),children:t}),(0,d.jsx)(ir.u,{items:e,nameMaxWidth:200,className:dv("result",{"no-title":!t}),responsive:!0})]}):null}var xv=a(87285);const bv=(e,t,a)=>{const{setActivePath:n}=a;return{openPreview:()=>{t(H.F.util.invalidateTags(["PreviewData"])),t((0,K.o)(!0)),t((0,oe.es)(ae.Dg.query)),t((0,oe.sH)(ae.tQ.newQuery)),n(e)}}},fv=(e,t)=>(0,d.jsx)(hn.$,{view:"flat-secondary",onClick:e.openPreview,title:Lr("actions.openPreview"),size:t||"s",children:(0,d.jsx)(ct.I,{data:xv.A})}),jv=(e,t,a)=>(n,r)=>{const s=bv(n,e,t),i=fv(s,a);return{async_replication:void 0,database:void 0,directory:void 0,table:i,column_table:i,index_table:void 0,topic:void 0,stream:void 0,index:void 0,external_table:i,external_data_source:void 0,view:i}[r]},Sv=(e,t,a)=>(n,r)=>{const s=bv(n,e,t);return{preview:fv(s,a)}[r]};var Tv=a(57949),Nv=a(1064);const Ev=5*Z.KF,wv=H.F.injectEndpoints({endpoints:e=>({getTableSchemaData:e.query({queryFn:async({path:e,tenantName:t,type:a},{dispatch:n})=>{try{if($(a)){const a=await n(wt.endpoints.getViewSchema.initiate({database:t,path:e,timeout:Ev}));if((0,Nt.We)(a))return{error:a};return{data:ta(a.data)}}const r=await n(G.endpoints.getOverview.initiate({path:e,database:t,timeout:Ev}));return{data:ea(a,r.data)}}catch(r){return{error:r}}}})})});var Cv=a(51016),Pv=a(49917),Iv=a(32133),Dv=a.n(Iv);function Av(e,t){const a=e.replace(/^\/+|\/+$/g,""),n=t.replace(/^\/+|\/+$/g,"");if(!a.startsWith(n))return a||"/";if(a===n)return`/${a}`;let r=a.slice(n.length);return r=r.replace(/^\/+/,"")||"/",r}function _v(e,t){return t===x.EPathTypeDir&&(2===e.split("/").length&&e.startsWith("/"))}const Rv=({text:e,action:t,isLoading:a})=>({text:(0,d.jsxs)(ot.s,{justifyContent:"space-between",alignItems:"center",children:[e,a&&(0,d.jsx)(Vm.t,{size:"xs"})]}),action:t,disabled:a}),kv=(e,t,a="")=>(n,r)=>{const s=((e,t,a)=>{const{setActivePath:n,showCreateDirectoryDialog:r,getConfirmation:s,getConnectToDBDialog:i,schemaData:o}=a,l=a=>()=>{const r=()=>{t((0,oe.es)(ae.Dg.query)),t((0,oe.sH)(ae.tQ.newQuery)),n(e.path),cm(a({...e,schemaData:o}))};s?s().then((e=>{e&&r()})):r()};return{createDirectory:r?()=>{r(e.path)}:void 0,getConnectToDBDialog:()=>null===i||void 0===i?void 0:i({database:e.path}),createTable:l(dm),createColumnTable:l(um),createAsyncReplication:l(mm),alterAsyncReplication:l(Nm),dropAsyncReplication:l(Tm),alterTable:l(pm),dropTable:l(Mm),selectQuery:l(hm),upsertQuery:l(vm),createExternalTable:l(ym),dropExternalTable:l(gm),selectQueryFromExternalTable:l(hm),createTopic:l(xm),alterTopic:l(bm),dropTopic:l(fm),createView:l(jm),dropView:l(Sm),dropIndex:l(wm),addTableIndex:l(Em),createCdcStream:l(Cm),copyPath:()=>{try{Dv()(e.relativePath),ht({name:"Copied",title:Lr("actions.copied"),type:"success"})}catch{ht({name:"Not copied",title:Lr("actions.notCopied"),type:"error"})}}}})({path:n,relativePath:Av(n,a),tenantName:a,type:r},e,t),i={text:Lr("actions.copyPath"),action:s.copyPath,iconEnd:(0,d.jsx)(Cv.A,{})},o={text:Lr("actions.connectToDB"),action:s.getConnectToDBDialog,iconEnd:(0,d.jsx)(Pv.A,{})},l=[{text:Lr("actions.createTable"),action:s.createTable},{text:Lr("actions.createColumnTable"),action:s.createColumnTable},{text:Lr("actions.createAsyncReplication"),action:s.createAsyncReplication},{text:Lr("actions.createTopic"),action:s.createTopic},{text:Lr("actions.createView"),action:s.createView}],c=[[i,o],l],u=[[i],l];if(s.createDirectory){const e={text:Lr("actions.createDirectory"),action:s.createDirectory};c.splice(1,0,[e]),u.splice(1,0,[e])}const m=[[i],[{text:Lr("actions.alterTable"),action:s.alterTable},{text:Lr("actions.dropTable"),action:s.dropTable},Rv({text:Lr("actions.selectQuery"),action:s.selectQuery,isLoading:t.isSchemaDataLoading}),Rv({text:Lr("actions.upsertQuery"),action:s.upsertQuery,isLoading:t.isSchemaDataLoading}),{text:Lr("actions.addTableIndex"),action:s.addTableIndex},{text:Lr("actions.createCdcStream"),action:s.createCdcStream}]],p=[[i],[{text:Lr("actions.alterTable"),action:s.alterTable},{text:Lr("actions.dropTable"),action:s.dropTable},{text:Lr("actions.selectQuery"),action:s.selectQuery},{text:Lr("actions.upsertQuery"),action:s.upsertQuery}]],h=[[i],[{text:Lr("actions.alterTopic"),action:s.alterTopic},{text:Lr("actions.dropTopic"),action:s.dropTopic}]],v=[[i],[{text:Lr("actions.selectQuery"),action:s.selectQueryFromExternalTable}],[{text:Lr("actions.dropTable"),action:s.dropExternalTable}]],g=[[i],[{text:Lr("actions.createExternalTable"),action:s.createExternalTable}]],y=[[i],[{text:Lr("actions.selectQuery"),action:s.selectQuery}],[{text:Lr("actions.dropView"),action:s.dropView}]],x=[i];return{async_replication:[[i],[{text:Lr("actions.alterReplication"),action:s.alterAsyncReplication},{text:Lr("actions.dropReplication"),action:s.dropAsyncReplication}]],database:c,directory:u,table:m,column_table:p,index_table:x,topic:h,stream:x,index:[[i,{text:Lr("actions.dropIndex"),action:s.dropIndex}]],external_table:v,external_data_source:g,view:y}[r]},Ov=(0,c.cn)("ydb-schema-create-directory-dialog"),Mv="relativePath";function Lv({open:e,onClose:t,database:a,parentPath:r,onSuccess:s}){const[i,o]=n.useState(""),[l,c]=n.useState(""),[u,m]=K.sM.useCreateDirectoryMutation(),p=()=>{o(""),m.reset()},h=()=>{t(),c(""),p()};return(0,d.jsxs)(Ri.l,{open:e,onClose:h,size:"s",children:[(0,d.jsx)(Ri.l.Header,{caption:Lr("schema.tree.dialog.header")}),(0,d.jsxs)("form",{onSubmit:e=>{e.preventDefault();const t=(n=l)?/\s/.test(n)?Lr("schema.tree.dialog.whitespace"):"":Lr("schema.tree.dialog.empty");var n;o(t),t||u({database:a,path:`${r}/${l}`}).unwrap().then((()=>{h(),s(l)}))},children:[(0,d.jsxs)(Ri.l.Body,{children:[(0,d.jsxs)("label",{htmlFor:Mv,className:Ov("label"),children:[(0,d.jsx)("span",{className:Ov("description"),children:Lr("schema.tree.dialog.description")}),`${r}/`]}),(0,d.jsx)("div",{className:Ov("input-wrapper"),children:(0,d.jsx)(Qi.k,{placeholder:Lr("schema.tree.dialog.placeholder"),value:l,onUpdate:e=>{c(e),p()},autoFocus:!0,hasClear:!0,autoComplete:!1,disabled:m.isLoading,validationState:i?"invalid":void 0,id:Mv,errorMessage:i})}),m.isError&&(0,d.jsx)(de.o,{error:m.error,defaultMessage:Lr("schema.tree.dialog.invalid")})]}),(0,d.jsx)(Ri.l.Footer,{loading:m.isLoading,textButtonApply:Lr("schema.tree.dialog.buttonApply"),textButtonCancel:Lr("schema.tree.dialog.buttonCancel"),onClickButtonCancel:h,propsButtonApply:{type:"submit"}})]})]})}const zv=n.createContext(void 0),Fv=n.createContext(void 0);function qv({children:e}){const[t,a]=n.useState("");return(0,d.jsx)(zv.Provider,{value:t,children:(0,d.jsx)(Fv.Provider,{value:a,children:e})})}function Qv(){const e=n.useContext(Fv);if(void 0===e)throw new Error("useDispatchTreeKey must be used within a TreeKeyProvider");return e}function Uv(e){const t=(0,ie.Ii)(),{rootPath:a,rootName:r,rootType:s,currentPath:i,onActivePathUpdate:o}=e,l=(0,X.YQ)(),c=(0,X.N4)(Ai.Wp),[u,{currentData:m,isFetching:p}]=wv.useLazyGetTableSchemaDataQuery(),[h,v]=(0,X.XS)(),[g,y]=n.useState(!1),[x,b]=n.useState(""),f=Qv(),j=function(){const e=n.useContext(zv);if(void 0===e)throw new Error("useTreeKey must be used within a TreeKeyProvider");return e}(),S=_v(a,s)?"database":E(s);n.useEffect((()=>{null!==i&&void 0!==i&&i.startsWith(a)||o(a)}),[i,o,a]);const T=e=>{b(e),y(!0)},w=n.useMemo((()=>kv(l,{setActivePath:o,updateQueryExecutionSettings:e=>v({...h,...e}),showCreateDirectoryDialog:t?T:void 0,getConfirmation:c?ao:void 0,getConnectToDBDialog:Nv.S,schemaData:m,isSchemaDataLoading:p},a)),[m,t,l,c,p,o,h,a,v]);return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)(Lv,{onClose:()=>{y(!1)},open:g,database:a,parentPath:x,onSuccess:e=>{const t=`${x}/${e}`;o(t),f(t)}}),(0,d.jsx)(Tv.F,{rootState:{path:a,name:r,type:S,collapsed:!1},fetchPath:async e=>{let t;for(;;){const n=l(K.sM.endpoints.getSchema.initiate({path:e,database:a},{forceRefetch:!0})),{data:r,originalArgs:s}=await n;if(n.unsubscribe(),(null===s||void 0===s?void 0:s.path)===e){t=null===r||void 0===r?void 0:r[e];break}}if(!t)throw new Error(`no describe data about path ${e}`);const{PathDescription:{Children:n=[]}={}}=t;return n.map((e=>{const{Name:t="",PathType:a,PathSubType:n,ChildrenExist:r}=e,s=Q(a,n)||(0,Br.f8)(r)&&!r;return{name:t,type:E(a,n),expandable:!s}}))},getActions:w,onActionsOpenToggle:({path:e,type:t,isOpen:n})=>{const r=N[t];return n&&r&&u({path:e,tenantName:a,type:r}),[]},renderAdditionalNodeElements:jv(l,{setActivePath:o}),activePath:i,onActivePathUpdate:o,cache:!1,virtualize:!0},j)]})}const Bv=JSON.parse('{"title_navigation":"Navigation","field_source-type":"Source Type","field_data-source":"Data Source","action_copySchemaPath":"Copy schema path","action_openInDiagnostics":"Open in Diagnostics","field_type":"Type","field_subtype":"SubType","field_id":"Id","field_version":"Version","field_created":"Created","field_data-size":"Data size","field_row-count":"Row count","field_partitions":"Partitions count","field_paths":"Paths","field_shards":"Shards","field_state":"State","field_mode":"Mode","field_format":"Format","field_retention":"Retention"}'),$v=(0,$e.g4)("ydb-object-summary",{en:Bv}),Hv=(0,c.cn)("ydb-object-summary");function Gv({tenantName:e,path:t}){var a;const{data:n={},isLoading:r}=(0,K.Tn)({path:e,database:e}),i=null===n||void 0===n||null===(a=n.PathDescription)||void 0===a?void 0:a.Self,[,o]=(0,s.useQueryParam)("schema",s.StringParam);return!i&&r?(0,d.jsx)("div",{children:(0,d.jsx)(ue.a,{})}):(0,d.jsxs)("div",{className:Hv("tree-wrapper"),children:[(0,d.jsx)("div",{className:Hv("tree-header"),children:$v("title_navigation")}),(0,d.jsx)("div",{className:Hv("tree"),children:i?(0,d.jsx)(Uv,{rootPath:e,rootName:i.Name||e,rootType:i.PathType,currentPath:t,onActivePathUpdate:o}):null})]})}var Wv=a(16963);function Vv(){const e=(0,X.YQ)(),{diagnosticsTab:t,tenantPage:a}=(0,X.N4)((e=>e.tenant)),n=a===ae.Dg.diagnostics&&t===ae.iJ.schema;return(0,d.jsx)("div",{children:!n&&(0,d.jsx)(hn.$,{title:$v("action_openInDiagnostics"),onClick:()=>{e((0,oe.es)(ae.Dg.diagnostics)),e((0,oe.WO)(ae.iJ.schema))},size:"s",children:(0,d.jsx)(ct.I,{data:Wv.A,size:14})})})}var Jv=a(8873),Yv=a(97091);function Kv(){const e=Qv();return(0,d.jsx)(lt.m,{title:"Refresh",children:(0,d.jsx)(hn.$,{className:Hv("refresh-button"),view:"flat-secondary",onClick:()=>{e((0,Yv.Ak)())},children:(0,d.jsx)(ct.I,{data:Jv.A})})})}const Zv=()=>({triggerExpand:!1,triggerCollapse:!1,collapsed:Boolean(localStorage.getItem(Z.hh))});function Xv({type:e,subType:t,tenantName:a,path:r,onCollapseSummary:i,onExpandSummary:o,isCollapsed:l}){var c;const[u]=(0,X.Nt)(),m=(0,X.YQ)(),[,p]=(0,s.useQueryParam)("schema",s.StringParam),[v,g]=n.useReducer(Au(Z.hh),void 0,Zv),{summaryTab:y=ae.ml.overview}=(0,X.N4)((e=>e.tenant)),f=(0,Xn.zy)(),j=Da().parse(f.search,{ignoreQueryPrefix:!0}),{currentData:S}=G.useGetOverviewQuery({path:r,database:a},{pollingInterval:u}),T=null===S||void 0===S||null===(c=S.PathDescription)||void 0===c?void 0:c.Self;n.useEffect((()=>{const t=D(e);!e||t||na.x$.find((e=>e.id===y))||m((0,oe.Mj)(ae.ml.overview))}),[m,e,y]);const N=()=>{const t=D(e)?[...na.x$,...na.nb]:na.x$;return(0,d.jsx)("div",{className:Hv("tabs"),children:(0,d.jsxs)(ot.s,{className:Hv("tabs-inner"),justifyContent:"space-between",alignItems:"center",children:[(0,d.jsx)(ne.t,{size:"l",items:t,activeTab:y,wrapTo:({id:e},t)=>{const a=(0,na.YL)({...j,[na.vh.summaryTab]:e});return(0,d.jsx)(re.N_,{to:a,className:Hv("tab"),children:t},e)},allowNotSelected:!0}),y===ae.ml.schema&&(0,d.jsx)(Vv,{})]})})},E=()=>{switch(y){case ae.ml.acl:return(0,d.jsx)(gv,{path:r,database:a});case ae.ml.schema:return(0,d.jsx)(aa,{type:e,path:r,tenantName:a});default:return(()=>{var e;if(!T)return;const{CreateStep:t,PathType:a,PathSubType:s,PathId:i,PathVersion:o}=T,l=[],c=_v(r,a)?"Domain":null===a||void 0===a?void 0:a.replace(/^EPathType/,"");l.push({name:$v("field_type"),content:c}),s!==b.EPathSubTypeEmpty&&l.push({name:$v("field_subtype"),content:null===s||void 0===s?void 0:s.replace(/^EPathSubType/,"")}),l.push({name:$v("field_id"),content:i}),l.push({name:$v("field_version"),content:o}),l.push({name:$v("field_created"),content:(0,he.r6)(t)});const{PathDescription:u}=S;if(null!==u&&void 0!==u&&u.TableStats){const{DataSize:e,RowCount:t}=u.TableStats;l.push({name:$v("field_data-size"),content:_n(e)},{name:$v("field_row-count"),content:(0,he.ZV)(t)})}const m=()=>{var e;const{PathsInside:t,ShardsInside:a,PathsLimit:n,ShardsLimit:r}=null!==(e=null===u||void 0===u?void 0:u.DomainDescription)&&void 0!==e?e:{};let s=(0,he.ZV)(t),i=(0,he.ZV)(a);return s&&n&&(s=`${s} / ${(0,he.ZV)(n)}`),i&&r&&(i=`${i} / ${(0,he.ZV)(r)}`),[{name:$v("field_paths"),content:s},{name:$v("field_shards"),content:i}]},p={[x.EPathTypeInvalid]:void 0,[x.EPathTypeDir]:void 0,[x.EPathTypeTable]:()=>{var e;return[{name:$v("field_partitions"),content:null===u||void 0===u||null===(e=u.TablePartitions)||void 0===e?void 0:e.length}]},[x.EPathTypeSubDomain]:m,[x.EPathTypeTableIndex]:void 0,[x.EPathTypeExtSubDomain]:m,[x.EPathTypeColumnStore]:()=>{var e,t;return[{name:$v("field_partitions"),content:null===u||void 0===u||null===(e=u.ColumnStoreDescription)||void 0===e||null===(t=e.ColumnShards)||void 0===t?void 0:t.length}]},[x.EPathTypeColumnTable]:()=>{var e,t,a;return[{name:$v("field_partitions"),content:null===u||void 0===u||null===(e=u.ColumnTableDescription)||void 0===e||null===(t=e.Sharding)||void 0===t||null===(a=t.ColumnShards)||void 0===a?void 0:a.length}]},[x.EPathTypeCdcStream]:()=>{const{Mode:e,Format:t}=(null===u||void 0===u?void 0:u.CdcStreamDescription)||{};return[{name:$v("field_mode"),content:null===e||void 0===e?void 0:e.replace(/^ECdcStreamMode/,"")},{name:$v("field_format"),content:null===t||void 0===t?void 0:t.replace(/^ECdcStreamFormat/,"")}]},[x.EPathTypePersQueueGroup]:()=>{var e,t,a;const n=null===u||void 0===u?void 0:u.PersQueueGroup,r=null===n||void 0===n||null===(e=n.PQTabletConfig)||void 0===e||null===(t=e.PartitionConfig)||void 0===t?void 0:t.LifetimeSeconds;return[{name:$v("field_partitions"),content:null===n||void 0===n||null===(a=n.Partitions)||void 0===a?void 0:a.length},{name:$v("field_retention"),content:r&&(0,he.Pt)(r)}]},[x.EPathTypeExternalTable]:()=>{var e,t;const a=(0,ye.Ow)({...j,schema:null===u||void 0===u||null===(e=u.ExternalTableDescription)||void 0===e?void 0:e.DataSourcePath}),{SourceType:n,DataSourcePath:r}=(null===u||void 0===u?void 0:u.ExternalTableDescription)||{},s=(null===r||void 0===r||null===(t=r.match(/([^/]*)\/*$/))||void 0===t?void 0:t[1])||"";return[{name:$v("field_source-type"),content:n},{name:$v("field_data-source"),content:r&&(0,d.jsx)("span",{title:r,children:(0,d.jsx)(er.K,{title:s||"",url:a})})}]},[x.EPathTypeExternalDataSource]:()=>{var e;return[{name:$v("field_source-type"),content:null===u||void 0===u||null===(e=u.ExternalDataSourceDescription)||void 0===e?void 0:e.SourceType}]},[x.EPathTypeView]:void 0,[x.EPathTypeReplication]:()=>{var e;const t=null===u||void 0===u||null===(e=u.ReplicationDescription)||void 0===e?void 0:e.State;return t?[{name:$v("field_state"),content:(0,d.jsx)(gr,{state:t})}]:[]}},h=a&&(null===(e=p[a])||void 0===e?void 0:e.call(p))||[];l.push(...h);const v=l.filter((e=>e.content)).map((e=>({...e,content:(0,d.jsx)("div",{className:Hv("overview-item-content"),children:e.content})})));return(0,d.jsxs)(n.Fragment,{children:[(0,d.jsx)("div",{className:Hv("overview-title"),children:(0,d.jsx)(zr,{data:u})}),(0,d.jsx)(sv.u,{responsive:!0,children:v.map((e=>(0,d.jsx)(sv.u.Item,{name:e.name,children:e.content},e.name)))})]})})()}},w=()=>{g(Pu.triggerCollapse)},C=()=>{g(Pu.triggerExpand)},P=()=>{g(Pu.clear)},I=Av(r,a),A=()=>{const a=D(e)&&!_(t);return(0,d.jsxs)(n.Fragment,{children:[a&&Sv(m,{setActivePath:p},"m")(r,"preview"),(0,d.jsx)(mn.b,{text:I,view:"flat-secondary",title:$v("action_copySchemaPath")}),(0,d.jsx)(Ru,{onCollapse:w,onExpand:C,isCollapsed:v.collapsed,initialDirection:"bottom"})]})},R=()=>{const{Status:t,Reason:a}=null!==S&&void 0!==S?S:{};if(e){let t=e.replace("EPathType","");return _v(r,e)&&(t="domain"),(0,d.jsx)("div",{className:Hv("entity-type"),children:t})}let n;return t&&a&&(n=`${t}: ${a}`),(0,d.jsx)("div",{className:Hv("entity-type",{error:!0}),children:(0,d.jsx)(_a.B,{content:n,offset:{left:0}})})};return(0,d.jsx)(qv,{children:(0,d.jsxs)("div",{className:Hv(),children:[(0,d.jsx)("div",{className:Hv({hidden:l}),children:(0,d.jsxs)(h,{direction:"vertical",defaultSizePaneKey:Z.ED,onSplitStartDragAdditional:P,triggerCollapse:v.triggerCollapse,triggerExpand:v.triggerExpand,minSize:[200,52],collapsedSizes:[100,0],children:[(0,d.jsx)(Gv,{tenantName:a,path:r}),(0,d.jsxs)("div",{className:Hv("info"),children:[(0,d.jsxs)("div",{className:Hv("sticky-top"),children:[(0,d.jsxs)("div",{className:Hv("info-header"),children:[(0,d.jsxs)("div",{className:Hv("info-title"),children:[R(),(0,d.jsx)("div",{className:Hv("path-name"),children:I})]}),(0,d.jsx)("div",{className:Hv("info-controls"),children:A()})]}),N()]}),(0,d.jsx)("div",{className:Hv("overview-wrapper"),children:E()})]})]})}),(0,d.jsxs)(ot.s,{className:Hv("actions"),gap:.5,children:[!l&&(0,d.jsx)(Kv,{}),(0,d.jsx)(Ru,{onCollapse:i,onExpand:o,isCollapsed:l,initialDirection:"left"})]})]})})}const eg=(0,c.cn)("tenant-page"),tg=()=>({triggerExpand:!1,triggerCollapse:!1,collapsed:Boolean(localStorage.getItem(Z.jX))});function ag(e){var t,l,c,u,m,p,g,y,x,b;const[f]=(0,X.Nt)(),[j,S]=n.useReducer(Au(Z.jX),void 0,tg),[{database:T,name:N,schema:E},w]=(0,s.useQueryParams)({database:s.StringParam,name:s.StringParam,schema:s.StringParam});n.useEffect((()=>{N&&!T&&w({database:N,name:void 0},"replaceIn")}),[T,N,w]);const C=null!==T&&void 0!==T?T:N;if(!C)throw new Error("Tenant name is not defined");const P=n.useRef();n.useEffect((()=>{if(P.current!==C){(async()=>{const{registerYQLCompletionItemProvider:e}=await a.e(4024).then(a.bind(a,94024));e(C)})().catch(console.error),P.current=C}}),[C]);const I=(0,X.YQ)();n.useEffect((()=>{I((0,v.g)("tenant",{tenantName:C}))}),[C,I]);const D=null!==E&&void 0!==E?E:C,{currentData:A,error:_,isLoading:R}=G.useGetOverviewQuery({path:D,database:C},{pollingInterval:f}),k=(0,X.N4)((e=>(0,K.Tp)(e,D,C))),O=null!==(t=null===A||void 0===A||null===(l=A.PathDescription)||void 0===l||null===(c=l.Self)||void 0===c?void 0:c.PathType)&&void 0!==t?t:null===k||void 0===k||null===(u=k.PathDescription)||void 0===u||null===(m=u.Self)||void 0===m?void 0:m.PathType,M=null!==(p=null===A||void 0===A||null===(g=A.PathDescription)||void 0===g||null===(y=g.Self)||void 0===y?void 0:y.PathSubType)&&void 0!==p?p:null===k||void 0===k||null===(x=k.PathDescription)||void 0===x||null===(b=x.Self)||void 0===b?void 0:b.PathSubType,L=(0,ee.Pq)(_),[z,F]=n.useState(!0);z&&!R&&F(!1);const q=D||Lr("page.title");return(0,d.jsxs)("div",{className:eg(),children:[(0,d.jsx)(r.mg,{defaultTitle:`${q} \u2014 YDB Monitoring`,titleTemplate:`%s \u2014 ${q} \u2014 YDB Monitoring`}),(0,d.jsx)(o.r,{loading:z,children:(0,d.jsx)(i.A,{error:L?_:void 0,children:(0,d.jsxs)(h,{defaultSizePaneKey:Z.jQ,defaultSizes:[25,75],triggerCollapse:j.triggerCollapse,triggerExpand:j.triggerExpand,minSize:[36,200],onSplitStartDragAdditional:()=>{S(Pu.clear)},children:[(0,d.jsx)(Xv,{type:O,subType:M,tenantName:C,path:D,onCollapseSummary:()=>{S(Pu.triggerCollapse)},onExpandSummary:()=>{S(Pu.triggerExpand)},isCollapsed:j.collapsed}),(0,d.jsx)("div",{className:eg("main"),children:(0,d.jsx)(rv,{type:O,additionalTenantProps:e.additionalTenantProps,additionalNodesProps:e.additionalNodesProps,tenantName:C,path:D})})]})})})]})}},5890:(e,t,a)=>{var n={"./simpleWorker":51929,"./simpleWorker.js":51929,"monaco-editor/esm/vs/base/common/worker/simpleWorker":51929,"monaco-editor/esm/vs/base/common/worker/simpleWorker.js":51929};function r(e){return Promise.resolve().then((()=>{if(!a.o(n,e)){var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}return a(n[e])}))}r.keys=()=>Object.keys(n),r.id=5890,e.exports=r},9204:(e,t,a)=>{var n={"./editorBaseApi":[73848],"./editorBaseApi.js":[73848],"./editorSimpleWorker":[16545],"./editorSimpleWorker.js":[16545],"./editorWorker":[10920],"./editorWorker.js":[10920],"./editorWorkerHost":[80718],"./editorWorkerHost.js":[80718],"./findSectionHeaders":[56691],"./findSectionHeaders.js":[56691],"./getIconClasses":[53068],"./getIconClasses.js":[53068],"./languageFeatureDebounce":[32500],"./languageFeatureDebounce.js":[32500],"./languageFeatures":[56942],"./languageFeatures.js":[56942],"./languageFeaturesService":[76007],"./languageFeaturesService.js":[76007],"./languageService":[17890],"./languageService.js":[17890],"./languagesAssociations":[99908],"./languagesAssociations.js":[99908],"./languagesRegistry":[69259],"./languagesRegistry.js":[69259],"./markerDecorations":[37550],"./markerDecorations.js":[37550],"./markerDecorationsService":[30707],"./markerDecorationsService.js":[30707],"./model":[23750],"./model.js":[23750],"./modelService":[16363],"./modelService.js":[16363],"./resolverService":[18938],"./resolverService.js":[18938],"./semanticTokensDto":[98232],"./semanticTokensDto.js":[98232],"./semanticTokensProviderStyling":[45538],"./semanticTokensProviderStyling.js":[45538],"./semanticTokensStyling":[74243],"./semanticTokensStyling.js":[74243],"./semanticTokensStylingService":[27004],"./semanticTokensStylingService.js":[27004],"./textModelSync/textModelSync.impl":[47443],"./textModelSync/textModelSync.impl.js":[47443],"./textModelSync/textModelSync.protocol":[28868,8868],"./textModelSync/textModelSync.protocol.js":[28868,8868],"./textResourceConfiguration":[90360],"./textResourceConfiguration.js":[90360],"./treeSitterParserService":[44432],"./treeSitterParserService.js":[44432],"./treeViewsDnd":[36723],"./treeViewsDnd.js":[36723],"./treeViewsDndService":[29100],"./treeViewsDndService.js":[29100],"./unicodeTextModelHighlighter":[74855],"./unicodeTextModelHighlighter.js":[74855],"monaco-editor/esm/vs/editor/common/services/editorBaseApi":[73848],"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":[73848],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":[16545],"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":[16545],"monaco-editor/esm/vs/editor/common/services/editorWorker":[10920],"monaco-editor/esm/vs/editor/common/services/editorWorker.js":[10920],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":[80718],"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":[80718],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":[56691],"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":[56691],"monaco-editor/esm/vs/editor/common/services/getIconClasses":[53068],"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":[53068],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":[32500],"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":[32500],"monaco-editor/esm/vs/editor/common/services/languageFeatures":[56942],"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":[56942],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":[76007],"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":[76007],"monaco-editor/esm/vs/editor/common/services/languageService":[17890],"monaco-editor/esm/vs/editor/common/services/languageService.js":[17890],"monaco-editor/esm/vs/editor/common/services/languagesAssociations":[99908],"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":[99908],"monaco-editor/esm/vs/editor/common/services/languagesRegistry":[69259],"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":[69259],"monaco-editor/esm/vs/editor/common/services/markerDecorations":[37550],"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":[37550],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":[30707],"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":[30707],"monaco-editor/esm/vs/editor/common/services/model":[23750],"monaco-editor/esm/vs/editor/common/services/model.js":[23750],"monaco-editor/esm/vs/editor/common/services/modelService":[16363],"monaco-editor/esm/vs/editor/common/services/modelService.js":[16363],"monaco-editor/esm/vs/editor/common/services/resolverService":[18938],"monaco-editor/esm/vs/editor/common/services/resolverService.js":[18938],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":[98232],"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":[98232],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":[45538],"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":[45538],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":[74243],"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":[74243],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":[27004],"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":[27004],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":[47443],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":[47443],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":[28868,8868],"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":[28868,8868],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":[90360],"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":[90360],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":[44432],"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":[44432],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":[36723],"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":[36723],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":[29100],"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":[29100],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":[74855],"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":[74855]};function r(e){if(!a.o(n,e))return Promise.resolve().then((()=>{var t=new Error("Cannot find module '"+e+"'");throw t.code="MODULE_NOT_FOUND",t}));var t=n[e],r=t[0];return Promise.all(t.slice(1).map(a.e)).then((()=>a(r)))}r.keys=()=>Object.keys(n),r.id=9204,e.exports=r},66574:()=>{},2748:()=>{},52246:()=>{}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42111.2a4b8434.chunk.js b/ydb/core/viewer/monitoring/static/js/42111.2a4b8434.chunk.js new file mode 100644 index 000000000000..c8f28d524183 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42111.2a4b8434.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42111],{42111:(e,t,i)=>{i.d(t,{default:()=>a});var n=i(54876);const a=i.n(n)()},54876:e=>{function t(e){e.languages.renpy={comment:{pattern:/(^|[^\\])#.+/,lookbehind:!0},string:{pattern:/("""|''')[\s\S]+?\1|("|')(?:\\.|(?!\2)[^\\])*\2|(?:^#?(?:(?:[0-9a-fA-F]){3}|[0-9a-fA-F]{6})$)/m,greedy:!0},function:/\b[a-z_]\w*(?=\()/i,property:/\b(?:Update|UpdateVersion|action|activate_sound|adv_nvl_transition|after_load_transition|align|alpha|alt|anchor|antialias|area|auto|background|bar_invert|bar_resizing|bar_vertical|black_color|bold|bottom_bar|bottom_gutter|bottom_margin|bottom_padding|box_reverse|box_wrap|can_update|caret|child|color|crop|default_afm_enable|default_afm_time|default_fullscreen|default_text_cps|developer|directory_name|drag_handle|drag_joined|drag_name|drag_raise|draggable|dragged|drop_shadow|drop_shadow_color|droppable|dropped|easein|easeout|edgescroll|end_game_transition|end_splash_transition|enter_replay_transition|enter_sound|enter_transition|enter_yesno_transition|executable_name|exit_replay_transition|exit_sound|exit_transition|exit_yesno_transition|fadein|fadeout|first_indent|first_spacing|fit_first|focus|focus_mask|font|foreground|game_main_transition|get_installed_packages|google_play_key|google_play_salt|ground|has_music|has_sound|has_voice|height|help|hinting|hover|hover_background|hover_color|hover_sound|hovered|hyperlink_functions|idle|idle_color|image_style|include_update|insensitive|insensitive_background|insensitive_color|inside|intra_transition|italic|justify|kerning|keyboard_focus|language|layer_clipping|layers|layout|left_bar|left_gutter|left_margin|left_padding|length|line_leading|line_overlap_split|line_spacing|linear|main_game_transition|main_menu_music|maximum|min_width|minimum|minwidth|modal|mouse|mousewheel|name|narrator_menu|newline_indent|nvl_adv_transition|offset|order_reverse|outlines|overlay_functions|pos|position|prefix|radius|range|rest_indent|right_bar|right_gutter|right_margin|right_padding|rotate|rotate_pad|ruby_style|sample_sound|save_directory|say_attribute_transition|screen_height|screen_width|scrollbars|selected_hover|selected_hover_color|selected_idle|selected_idle_color|selected_insensitive|show_side_image|show_two_window|side_spacing|side_xpos|side_ypos|size|size_group|slow_cps|slow_cps_multiplier|spacing|strikethrough|subpixel|text_align|text_style|text_xpos|text_y_fudge|text_ypos|thumb|thumb_offset|thumb_shadow|thumbnail_height|thumbnail_width|time|top_bar|top_gutter|top_margin|top_padding|translations|underline|unscrollable|update|value|version|version_name|version_tuple|vertical|width|window_hide_transition|window_icon|window_left_padding|window_show_transition|window_title|windows_icon|xadjustment|xalign|xanchor|xanchoraround|xaround|xcenter|xfill|xinitial|xmargin|xmaximum|xminimum|xoffset|xofsset|xpadding|xpos|xsize|xzoom|yadjustment|yalign|yanchor|yanchoraround|yaround|ycenter|yfill|yinitial|ymargin|ymaximum|yminimum|yoffset|ypadding|ypos|ysize|ysizexysize|yzoom|zoom|zorder)\b/,tag:/\b(?:bar|block|button|buttoscreenn|drag|draggroup|fixed|frame|grid|[hv]box|hotbar|hotspot|image|imagebutton|imagemap|input|key|label|menu|mm_menu_frame|mousearea|nvl|parallel|screen|self|side|tag|text|textbutton|timer|vbar|viewport|window)\b|\$/,keyword:/\b(?:None|add|adjustment|alignaround|allow|angle|animation|around|as|assert|behind|box_layout|break|build|cache|call|center|changed|child_size|choice|circles|class|clear|clicked|clipping|clockwise|config|contains|continue|corner1|corner2|counterclockwise|def|default|define|del|delay|disabled|disabled_text|dissolve|elif|else|event|except|exclude|exec|expression|fade|finally|for|from|function|global|gm_root|has|hide|id|if|import|in|init|is|jump|knot|lambda|left|less_rounded|mm_root|movie|music|null|on|onlayer|pass|pause|persistent|play|print|python|queue|raise|random|renpy|repeat|return|right|rounded_window|scene|scope|set|show|slow|slow_abortable|slow_done|sound|stop|store|style|style_group|substitute|suffix|theme|transform|transform_anchor|transpose|try|ui|unhovered|updater|use|voice|while|widget|widget_hover|widget_selected|widget_text|yield)\b/,boolean:/\b(?:[Ff]alse|[Tt]rue)\b/,number:/(?:\b(?:0[bo])?(?:(?:\d|0x[\da-f])[\da-f]*(?:\.\d*)?)|\B\.\d+)(?:e[+-]?\d+)?j?/i,operator:/[-+%=]=?|!=|\*\*?=?|\/\/?=?|<[<=>]?|>[=>]?|[&|^~]|\b(?:and|at|not|or|with)\b/,punctuation:/[{}[\];(),.:]/},e.languages.rpy=e.languages.renpy}e.exports=t,t.displayName="renpy",t.aliases=["rpy"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42182.a71d5155.chunk.js b/ydb/core/viewer/monitoring/static/js/42182.a71d5155.chunk.js new file mode 100644 index 000000000000..b52f0ac19e3b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42182.a71d5155.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 42182.a71d5155.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42182],{42182:(e,n,s)=>{s.r(n),s.d(n,{conf:()=>i,language:()=>t});var i={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">",notIn:["string"]}],surroundingPairs:[{open:"(",close:")"},{open:"[",close:"]"},{open:"`",close:"`"}],folding:{markers:{start:new RegExp("^\\s*\x3c!--\\s*#?region\\b.*--\x3e"),end:new RegExp("^\\s*\x3c!--\\s*#?endregion\\b.*--\x3e")}}},t={defaultToken:"",tokenPostfix:".rst",control:/[\\`*_\[\]{}()#+\-\.!]/,escapes:/\\(?:@control)/,empty:["area","base","basefont","br","col","frame","hr","img","input","isindex","link","meta","param"],alphanumerics:/[A-Za-z0-9]/,simpleRefNameWithoutBq:/(?:@alphanumerics[-_+:.]*@alphanumerics)+|(?:@alphanumerics+)/,simpleRefName:/(?:`@phrase`|@simpleRefNameWithoutBq)/,phrase:/@simpleRefNameWithoutBq(?:\s@simpleRefNameWithoutBq)*/,citationName:/[A-Za-z][A-Za-z0-9-_.]*/,blockLiteralStart:/(?:[!"#$%&'()*+,-./:;<=>?@\[\]^_`{|}~]|[\s])/,precedingChars:/(?:[ -:/'"<([{])/,followingChars:/(?:[ -.,:;!?/'")\]}>]|$)/,punctuation:/(=|-|~|`|#|"|\^|\+|\*|:|\.|'|_|\+)/,tokenizer:{root:[[/^(@punctuation{3,}$){1,1}?/,"keyword"],[/^\s*([\*\-+\u2023\u2022]|[a-zA-Z0-9]+\.|\([a-zA-Z0-9]+\)|[a-zA-Z0-9]+\))\s/,"keyword"],[/([ ]::)\s*$/,"keyword","@blankLineOfLiteralBlocks"],[/(::)\s*$/,"keyword","@blankLineOfLiteralBlocks"],{include:"@tables"},{include:"@explicitMarkupBlocks"},{include:"@inlineMarkup"}],explicitMarkupBlocks:[{include:"@citations"},{include:"@footnotes"},[/^(\.\.\s)(@simpleRefName)(::\s)(.*)$/,[{token:"",next:"subsequentLines"},"keyword","",""]],[/^(\.\.)(\s+)(_)(@simpleRefName)(:)(\s+)(.*)/,[{token:"",next:"hyperlinks"},"","","string.link","","","string.link"]],[/^((?:(?:\.\.)(?:\s+))?)(__)(:)(\s+)(.*)/,[{token:"",next:"subsequentLines"},"","","","string.link"]],[/^(__\s+)(.+)/,["","string.link"]],[/^(\.\.)( \|)([^| ]+[^|]*[^| ]*)(\| )(@simpleRefName)(:: .*)/,[{token:"",next:"subsequentLines"},"","string.link","","keyword",""],"@rawBlocks"],[/(\|)([^| ]+[^|]*[^| ]*)(\|_{0,2})/,["","string.link",""]],[/^(\.\.)([ ].*)$/,[{token:"",next:"@comments"},"comment"]]],inlineMarkup:[{include:"@citationsReference"},{include:"@footnotesReference"},[/(@simpleRefName)(_{1,2})/,["string.link",""]],[/(`)([^<`]+\s+)(<)(.*)(>)(`)(_)/,["","string.link","","string.link","","",""]],[/\*\*([^\\*]|\*(?!\*))+\*\*/,"strong"],[/\*[^*]+\*/,"emphasis"],[/(``)((?:[^`]|\`(?!`))+)(``)/,["","keyword",""]],[/(__\s+)(.+)/,["","keyword"]],[/(:)((?:@simpleRefNameWithoutBq)?)(:`)([^`]+)(`)/,["","keyword","","",""]],[/(`)([^`]+)(`:)((?:@simpleRefNameWithoutBq)?)(:)/,["","","","keyword",""]],[/(`)([^`]+)(`)/,""],[/(_`)(@phrase)(`)/,["","string.link",""]]],citations:[[/^(\.\.\s+\[)((?:@citationName))(\]\s+)(.*)/,[{token:"",next:"@subsequentLines"},"string.link","",""]]],citationsReference:[[/(\[)(@citationName)(\]_)/,["","string.link",""]]],footnotes:[[/^(\.\.\s+\[)((?:[0-9]+))(\]\s+.*)/,[{token:"",next:"@subsequentLines"},"string.link",""]],[/^(\.\.\s+\[)((?:#@simpleRefName?))(\]\s+)(.*)/,[{token:"",next:"@subsequentLines"},"string.link","",""]],[/^(\.\.\s+\[)((?:\*))(\]\s+)(.*)/,[{token:"",next:"@subsequentLines"},"string.link","",""]]],footnotesReference:[[/(\[)([0-9]+)(\])(_)/,["","string.link","",""]],[/(\[)(#@simpleRefName?)(\])(_)/,["","string.link","",""]],[/(\[)(\*)(\])(_)/,["","string.link","",""]]],blankLineOfLiteralBlocks:[[/^$/,"","@subsequentLinesOfLiteralBlocks"],[/^.*$/,"","@pop"]],subsequentLinesOfLiteralBlocks:[[/(@blockLiteralStart+)(.*)/,["keyword",""]],[/^(?!blockLiteralStart)/,"","@popall"]],subsequentLines:[[/^[\s]+.*/,""],[/^(?!\s)/,"","@pop"]],hyperlinks:[[/^[\s]+.*/,"string.link"],[/^(?!\s)/,"","@pop"]],comments:[[/^[\s]+.*/,"comment"],[/^(?!\s)/,"","@pop"]],tables:[[/\+-[+-]+/,"keyword"],[/\+=[+=]+/,"keyword"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4534.b98f1389.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/42182.a71d5155.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/4534.b98f1389.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/42182.a71d5155.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/42384.403ac671.chunk.js b/ydb/core/viewer/monitoring/static/js/42384.403ac671.chunk.js new file mode 100644 index 000000000000..a718622b42b9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42384.403ac671.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42384],{23579:e=>{function n(e){!function(e){var n=/\([^|()\n]+\)|\[[^\]\n]+\]|\{[^}\n]+\}/.source,i=/\)|\((?![^|()\n]+\))/.source;function t(e,t){return RegExp(e.replace(//g,(function(){return"(?:"+n+")"})).replace(//g,(function(){return"(?:"+i+")"})),t||"")}var o={css:{pattern:/\{[^{}]+\}/,inside:{rest:e.languages.css}},"class-id":{pattern:/(\()[^()]+(?=\))/,lookbehind:!0,alias:"attr-value"},lang:{pattern:/(\[)[^\[\]]+(?=\])/,lookbehind:!0,alias:"attr-value"},punctuation:/[\\\/]\d+|\S/},a=e.languages.textile=e.languages.extend("markup",{phrase:{pattern:/(^|\r|\n)\S[\s\S]*?(?=$|\r?\n\r?\n|\r\r)/,lookbehind:!0,inside:{"block-tag":{pattern:t(/^[a-z]\w*(?:||[<>=])*\./.source),inside:{modifier:{pattern:t(/(^[a-z]\w*)(?:||[<>=])+(?=\.)/.source),lookbehind:!0,inside:o},tag:/^[a-z]\w*/,punctuation:/\.$/}},list:{pattern:t(/^[*#]+*\s+\S.*/.source,"m"),inside:{modifier:{pattern:t(/(^[*#]+)+/.source),lookbehind:!0,inside:o},punctuation:/^[*#]+/}},table:{pattern:t(/^(?:(?:||[<>=^~])+\.\s*)?(?:\|(?:(?:||[<>=^~_]|[\\/]\d+)+\.|(?!(?:||[<>=^~_]|[\\/]\d+)+\.))[^|]*)+\|/.source,"m"),inside:{modifier:{pattern:t(/(^|\|(?:\r?\n|\r)?)(?:||[<>=^~_]|[\\/]\d+)+(?=\.)/.source),lookbehind:!0,inside:o},punctuation:/\||^\./}},inline:{pattern:t(/(^|[^a-zA-Z\d])(\*\*|__|\?\?|[*_%@+\-^~])*.+?\2(?![a-zA-Z\d])/.source),lookbehind:!0,inside:{bold:{pattern:t(/(^(\*\*?)*).+?(?=\2)/.source),lookbehind:!0},italic:{pattern:t(/(^(__?)*).+?(?=\2)/.source),lookbehind:!0},cite:{pattern:t(/(^\?\?*).+?(?=\?\?)/.source),lookbehind:!0,alias:"string"},code:{pattern:t(/(^@*).+?(?=@)/.source),lookbehind:!0,alias:"keyword"},inserted:{pattern:t(/(^\+*).+?(?=\+)/.source),lookbehind:!0},deleted:{pattern:t(/(^-*).+?(?=-)/.source),lookbehind:!0},span:{pattern:t(/(^%*).+?(?=%)/.source),lookbehind:!0},modifier:{pattern:t(/(^\*\*|__|\?\?|[*_%@+\-^~])+/.source),lookbehind:!0,inside:o},punctuation:/[*_%?@+\-^~]+/}},"link-ref":{pattern:/^\[[^\]]+\]\S+$/m,inside:{string:{pattern:/(^\[)[^\]]+(?=\])/,lookbehind:!0},url:{pattern:/(^\])\S+$/,lookbehind:!0},punctuation:/[\[\]]/}},link:{pattern:t(/"*[^"]+":.+?(?=[^\w/]?(?:\s|$))/.source),inside:{text:{pattern:t(/(^"*)[^"]+(?=")/.source),lookbehind:!0},modifier:{pattern:t(/(^")+/.source),lookbehind:!0,inside:o},url:{pattern:/(:).+/,lookbehind:!0},punctuation:/[":]/}},image:{pattern:t(/!(?:||[<>=])*(?![<>=])[^!\s()]+(?:\([^)]+\))?!(?::.+?(?=[^\w/]?(?:\s|$)))?/.source),inside:{source:{pattern:t(/(^!(?:||[<>=])*)(?![<>=])[^!\s()]+(?:\([^)]+\))?(?=!)/.source),lookbehind:!0,alias:"url"},modifier:{pattern:t(/(^!)(?:||[<>=])+/.source),lookbehind:!0,inside:o},url:{pattern:/(:).+/,lookbehind:!0},punctuation:/[!:]/}},footnote:{pattern:/\b\[\d+\]/,alias:"comment",inside:{punctuation:/\[|\]/}},acronym:{pattern:/\b[A-Z\d]+\([^)]+\)/,inside:{comment:{pattern:/(\()[^()]+(?=\))/,lookbehind:!0},punctuation:/[()]/}},mark:{pattern:/\b\((?:C|R|TM)\)/,alias:"comment",inside:{punctuation:/[()]/}}}}}),r=a.phrase.inside,s={inline:r.inline,link:r.link,image:r.image,footnote:r.footnote,acronym:r.acronym,mark:r.mark};a.tag.pattern=/<\/?(?!\d)[a-z0-9]+(?:\s+[^\s>\/=]+(?:=(?:("|')(?:\\[\s\S]|(?!\1)[^\\])*\1|[^\s'">=]+))?)*\s*\/?>/i;var d=r.inline.inside;d.bold.inside=s,d.italic.inside=s,d.inserted.inside=s,d.deleted.inside=s,d.span.inside=s;var l=r.table.inside;l.inline=s.inline,l.link=s.link,l.image=s.image,l.footnote=s.footnote,l.acronym=s.acronym,l.mark=s.mark}(e)}e.exports=n,n.displayName="textile",n.aliases=[]},42384:(e,n,i)=>{i.d(n,{default:()=>o});var t=i(23579);const o=i.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42396.9af219b0.chunk.js b/ydb/core/viewer/monitoring/static/js/42396.9af219b0.chunk.js new file mode 100644 index 000000000000..6546dcaf245f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42396.9af219b0.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42396],{42396:(e,t,n)=>{n.d(t,{default:()=>a});var o=n(52627);const a=n.n(o)()},52627:e=>{function t(e){!function(e){var t=/\b(?:about|and|animate|as|at|attributes|by|case|catch|collect|continue|coordsys|do|else|exit|fn|for|from|function|global|if|in|local|macroscript|mapped|max|not|of|off|on|or|parameters|persistent|plugin|rcmenu|return|rollout|set|struct|then|throw|to|tool|try|undo|utility|when|where|while|with)\b/i;e.languages.maxscript={comment:{pattern:/\/\*[\s\S]*?(?:\*\/|$)|--.*/,greedy:!0},string:{pattern:/(^|[^"\\@])(?:"(?:[^"\\]|\\[\s\S])*"|@"[^"]*")/,lookbehind:!0,greedy:!0},path:{pattern:/\$(?:[\w/\\.*?]|'[^']*')*/,greedy:!0,alias:"string"},"function-call":{pattern:RegExp("((?:"+/^/.source+"|"+/[;=<>+\-*/^({\[]/.source+"|"+/\b(?:and|by|case|catch|collect|do|else|if|in|not|or|return|then|to|try|where|while|with)\b/.source+")[ \t]*)(?!"+t.source+")"+/[a-z_]\w*\b/.source+"(?=[ \t]*(?:(?!"+t.source+")"+/[a-z_]/.source+"|"+/\d|-\.?\d/.source+"|"+/[({'"$@#?]/.source+"))","im"),lookbehind:!0,greedy:!0,alias:"function"},"function-definition":{pattern:/(\b(?:fn|function)\s+)\w+\b/i,lookbehind:!0,alias:"function"},argument:{pattern:/\b[a-z_]\w*(?=:)/i,alias:"attr-name"},keyword:t,boolean:/\b(?:false|true)\b/,time:{pattern:/(^|[^\w.])(?:(?:(?:\d+(?:\.\d*)?|\.\d+)(?:[eEdD][+-]\d+|[LP])?[msft])+|\d+:\d+(?:\.\d*)?)(?![\w.:])/,lookbehind:!0,alias:"number"},number:[{pattern:/(^|[^\w.])(?:(?:\d+(?:\.\d*)?|\.\d+)(?:[eEdD][+-]\d+|[LP])?|0x[a-fA-F0-9]+)(?![\w.:])/,lookbehind:!0},/\b(?:e|pi)\b/],constant:/\b(?:dontcollect|ok|silentValue|undefined|unsupplied)\b/,color:{pattern:/\b(?:black|blue|brown|gray|green|orange|red|white|yellow)\b/i,alias:"constant"},operator:/[-+*/<>=!]=?|[&^?]|#(?!\()/,punctuation:/[()\[\]{}.:,;]|#(?=\()|\\$/m}}(e)}e.exports=t,t.displayName="maxscript",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4243.697ce022.chunk.js b/ydb/core/viewer/monitoring/static/js/4243.697ce022.chunk.js new file mode 100644 index 000000000000..1154c43a8614 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/4243.697ce022.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4243],{4243:(e,n,t)=>{t.d(n,{default:()=>a});var r=t(65634);const a=t.n(r)()},65634:(e,n,t)=>{var r=t(90160);function a(e){e.register(r),function(e){e.languages.haml={"multiline-comment":{pattern:/((?:^|\r?\n|\r)([\t ]*))(?:\/|-#).*(?:(?:\r?\n|\r)\2[\t ].+)*/,lookbehind:!0,alias:"comment"},"multiline-code":[{pattern:/((?:^|\r?\n|\r)([\t ]*)(?:[~-]|[&!]?=)).*,[\t ]*(?:(?:\r?\n|\r)\2[\t ].*,[\t ]*)*(?:(?:\r?\n|\r)\2[\t ].+)/,lookbehind:!0,inside:e.languages.ruby},{pattern:/((?:^|\r?\n|\r)([\t ]*)(?:[~-]|[&!]?=)).*\|[\t ]*(?:(?:\r?\n|\r)\2[\t ].*\|[\t ]*)*/,lookbehind:!0,inside:e.languages.ruby}],filter:{pattern:/((?:^|\r?\n|\r)([\t ]*)):[\w-]+(?:(?:\r?\n|\r)(?:\2[\t ].+|\s*?(?=\r?\n|\r)))+/,lookbehind:!0,inside:{"filter-name":{pattern:/^:[\w-]+/,alias:"symbol"}}},markup:{pattern:/((?:^|\r?\n|\r)[\t ]*)<.+/,lookbehind:!0,inside:e.languages.markup},doctype:{pattern:/((?:^|\r?\n|\r)[\t ]*)!!!(?: .+)?/,lookbehind:!0},tag:{pattern:/((?:^|\r?\n|\r)[\t ]*)[%.#][\w\-#.]*[\w\-](?:\([^)]+\)|\{(?:\{[^}]+\}|[^{}])+\}|\[[^\]]+\])*[\/<>]*/,lookbehind:!0,inside:{attributes:[{pattern:/(^|[^#])\{(?:\{[^}]+\}|[^{}])+\}/,lookbehind:!0,inside:e.languages.ruby},{pattern:/\([^)]+\)/,inside:{"attr-value":{pattern:/(=\s*)(?:"(?:\\.|[^\\"\r\n])*"|[^)\s]+)/,lookbehind:!0},"attr-name":/[\w:-]+(?=\s*!?=|\s*[,)])/,punctuation:/[=(),]/}},{pattern:/\[[^\]]+\]/,inside:e.languages.ruby}],punctuation:/[<>]/}},code:{pattern:/((?:^|\r?\n|\r)[\t ]*(?:[~-]|[&!]?=)).+/,lookbehind:!0,inside:e.languages.ruby},interpolation:{pattern:/#\{[^}]+\}/,inside:{delimiter:{pattern:/^#\{|\}$/,alias:"punctuation"},ruby:{pattern:/[\s\S]+/,inside:e.languages.ruby}}},punctuation:{pattern:/((?:^|\r?\n|\r)[\t ]*)[~=\-&!]+/,lookbehind:!0}};for(var n=["css",{filter:"coffee",language:"coffeescript"},"erb","javascript","less","markdown","ruby","scss","textile"],t={},r=0,a=n.length;r{function n(e){!function(e){e.languages.ruby=e.languages.extend("clike",{comment:{pattern:/#.*|^=begin\s[\s\S]*?^=end/m,greedy:!0},"class-name":{pattern:/(\b(?:class|module)\s+|\bcatch\s+\()[\w.\\]+|\b[A-Z_]\w*(?=\s*\.\s*new\b)/,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:BEGIN|END|alias|and|begin|break|case|class|def|define_method|defined|do|each|else|elsif|end|ensure|extend|for|if|in|include|module|new|next|nil|not|or|prepend|private|protected|public|raise|redo|require|rescue|retry|return|self|super|then|throw|undef|unless|until|when|while|yield)\b/,operator:/\.{2,3}|&\.|===||[!=]?~|(?:&&|\|\||<<|>>|\*\*|[+\-*/%<>!^&|=])=?|[?:]/,punctuation:/[(){}[\].,;]/}),e.languages.insertBefore("ruby","operator",{"double-colon":{pattern:/::/,alias:"punctuation"}});var n={pattern:/((?:^|[^\\])(?:\\{2})*)#\{(?:[^{}]|\{[^{}]*\})*\}/,lookbehind:!0,inside:{content:{pattern:/^(#\{)[\s\S]+(?=\}$)/,lookbehind:!0,inside:e.languages.ruby},delimiter:{pattern:/^#\{|\}$/,alias:"punctuation"}}};delete e.languages.ruby.function;var t="(?:"+[/([^a-zA-Z0-9\s{(\[<=])(?:(?!\1)[^\\]|\\[\s\S])*\1/.source,/\((?:[^()\\]|\\[\s\S]|\((?:[^()\\]|\\[\s\S])*\))*\)/.source,/\{(?:[^{}\\]|\\[\s\S]|\{(?:[^{}\\]|\\[\s\S])*\})*\}/.source,/\[(?:[^\[\]\\]|\\[\s\S]|\[(?:[^\[\]\\]|\\[\s\S])*\])*\]/.source,/<(?:[^<>\\]|\\[\s\S]|<(?:[^<>\\]|\\[\s\S])*>)*>/.source].join("|")+")",r=/(?:"(?:\\.|[^"\\\r\n])*"|(?:\b[a-zA-Z_]\w*|[^\s\0-\x7F]+)[?!]?|\$.)/.source;e.languages.insertBefore("ruby","keyword",{"regex-literal":[{pattern:RegExp(/%r/.source+t+/[egimnosux]{0,6}/.source),greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}},{pattern:/(^|[^/])\/(?!\/)(?:\[[^\r\n\]]+\]|\\.|[^[/\\\r\n])+\/[egimnosux]{0,6}(?=\s*(?:$|[\r\n,.;})#]))/,lookbehind:!0,greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}}],variable:/[@$]+[a-zA-Z_]\w*(?:[?!]|\b)/,symbol:[{pattern:RegExp(/(^|[^:]):/.source+r),lookbehind:!0,greedy:!0},{pattern:RegExp(/([\r\n{(,][ \t]*)/.source+r+/(?=:(?!:))/.source),lookbehind:!0,greedy:!0}],"method-definition":{pattern:/(\bdef\s+)\w+(?:\s*\.\s*\w+)?/,lookbehind:!0,inside:{function:/\b\w+$/,keyword:/^self\b/,"class-name":/^\w+/,punctuation:/\./}}}),e.languages.insertBefore("ruby","string",{"string-literal":[{pattern:RegExp(/%[qQiIwWs]?/.source+t),greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/("|')(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|(?!\1)[^\\#\r\n])*\1/,greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?([a-z_]\w*)[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?[a-z_]\w*|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?/}},interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?'([a-z_]\w*)'[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?'[a-z_]\w*'|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?'|'$/}},string:/[\s\S]+/}}],"command-literal":[{pattern:RegExp(/%x/.source+t),greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}},{pattern:/`(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|[^\\`#\r\n])*`/,greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}}]}),delete e.languages.ruby.string,e.languages.insertBefore("ruby","number",{builtin:/\b(?:Array|Bignum|Binding|Class|Continuation|Dir|Exception|FalseClass|File|Fixnum|Float|Hash|IO|Integer|MatchData|Method|Module|NilClass|Numeric|Object|Proc|Range|Regexp|Stat|String|Struct|Symbol|TMS|Thread|ThreadGroup|Time|TrueClass)\b/,constant:/\b[A-Z][A-Z0-9_]*(?:[?!]|\b)/}),e.languages.rb=e.languages.ruby}(e)}e.exports=n,n.displayName="ruby",n.aliases=["rb"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42612.7c3ffc1d.chunk.js b/ydb/core/viewer/monitoring/static/js/42612.7c3ffc1d.chunk.js new file mode 100644 index 000000000000..7d4654a6b06f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42612.7c3ffc1d.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42612],{42612:function(t,h,_){t.exports=function(t){"use strict";function h(t){return t&&"object"==typeof t&&"default"in t?t:{default:t}}var _=h(t),n={name:"vi",weekdays:"ch\u1ee7 nh\u1eadt_th\u1ee9 hai_th\u1ee9 ba_th\u1ee9 t\u01b0_th\u1ee9 n\u0103m_th\u1ee9 s\xe1u_th\u1ee9 b\u1ea3y".split("_"),months:"th\xe1ng 1_th\xe1ng 2_th\xe1ng 3_th\xe1ng 4_th\xe1ng 5_th\xe1ng 6_th\xe1ng 7_th\xe1ng 8_th\xe1ng 9_th\xe1ng 10_th\xe1ng 11_th\xe1ng 12".split("_"),weekStart:1,weekdaysShort:"CN_T2_T3_T4_T5_T6_T7".split("_"),monthsShort:"Th01_Th02_Th03_Th04_Th05_Th06_Th07_Th08_Th09_Th10_Th11_Th12".split("_"),weekdaysMin:"CN_T2_T3_T4_T5_T6_T7".split("_"),ordinal:function(t){return t},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM [n\u0103m] YYYY",LLL:"D MMMM [n\u0103m] YYYY HH:mm",LLLL:"dddd, D MMMM [n\u0103m] YYYY HH:mm",l:"DD/M/YYYY",ll:"D MMM YYYY",lll:"D MMM YYYY HH:mm",llll:"ddd, D MMM YYYY HH:mm"},relativeTime:{future:"%s t\u1edbi",past:"%s tr\u01b0\u1edbc",s:"v\xe0i gi\xe2y",m:"m\u1ed9t ph\xfat",mm:"%d ph\xfat",h:"m\u1ed9t gi\u1edd",hh:"%d gi\u1edd",d:"m\u1ed9t ng\xe0y",dd:"%d ng\xe0y",M:"m\u1ed9t th\xe1ng",MM:"%d th\xe1ng",y:"m\u1ed9t n\u0103m",yy:"%d n\u0103m"}};return _.default.locale(n,null,!0),n}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42615.93e0f1f6.chunk.js b/ydb/core/viewer/monitoring/static/js/42615.93e0f1f6.chunk.js new file mode 100644 index 000000000000..1744b18714ce --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42615.93e0f1f6.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42615],{42615:(e,t,n)=>{n.d(t,{default:()=>i});var a=n(84730);const i=n.n(a)()},84730:e=>{function t(e){e.languages.vala=e.languages.extend("clike",{"class-name":[{pattern:/\b[A-Z]\w*(?:\.\w+)*\b(?=(?:\?\s+|\*?\s+\*?)\w)/,inside:{punctuation:/\./}},{pattern:/(\[)[A-Z]\w*(?:\.\w+)*\b/,lookbehind:!0,inside:{punctuation:/\./}},{pattern:/(\b(?:class|interface)\s+[A-Z]\w*(?:\.\w+)*\s*:\s*)[A-Z]\w*(?:\.\w+)*\b/,lookbehind:!0,inside:{punctuation:/\./}},{pattern:/((?:\b(?:class|enum|interface|new|struct)\s+)|(?:catch\s+\())[A-Z]\w*(?:\.\w+)*\b/,lookbehind:!0,inside:{punctuation:/\./}}],keyword:/\b(?:abstract|as|assert|async|base|bool|break|case|catch|char|class|const|construct|continue|default|delegate|delete|do|double|dynamic|else|ensures|enum|errordomain|extern|finally|float|for|foreach|get|if|in|inline|int|int16|int32|int64|int8|interface|internal|is|lock|long|namespace|new|null|out|override|owned|params|private|protected|public|ref|requires|return|set|short|signal|sizeof|size_t|ssize_t|static|string|struct|switch|this|throw|throws|try|typeof|uchar|uint|uint16|uint32|uint64|uint8|ulong|unichar|unowned|ushort|using|value|var|virtual|void|volatile|weak|while|yield)\b/i,function:/\b\w+(?=\s*\()/,number:/(?:\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)(?:f|u?l?)?/i,operator:/\+\+|--|&&|\|\||<<=?|>>=?|=>|->|~|[+\-*\/%&^|=!<>]=?|\?\??|\.\.\./,punctuation:/[{}[\];(),.:]/,constant:/\b[A-Z0-9_]+\b/}),e.languages.insertBefore("vala","string",{"raw-string":{pattern:/"""[\s\S]*?"""/,greedy:!0,alias:"string"},"template-string":{pattern:/@"[\s\S]*?"/,greedy:!0,inside:{interpolation:{pattern:/\$(?:\([^)]*\)|[a-zA-Z]\w*)/,inside:{delimiter:{pattern:/^\$\(?|\)$/,alias:"punctuation"},rest:e.languages.vala}},string:/[\s\S]+/}}}),e.languages.insertBefore("vala","keyword",{regex:{pattern:/\/(?:\[(?:[^\]\\\r\n]|\\.)*\]|\\.|[^/\\\[\r\n])+\/[imsx]{0,4}(?=\s*(?:$|[\r\n,.;})\]]))/,greedy:!0,inside:{"regex-source":{pattern:/^(\/)[\s\S]+(?=\/[a-z]*$)/,lookbehind:!0,alias:"language-regex",inside:e.languages.regex},"regex-delimiter":/^\//,"regex-flags":/^[a-z]+$/}}})}e.exports=t,t.displayName="vala",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42791.26100ebe.chunk.js b/ydb/core/viewer/monitoring/static/js/42791.26100ebe.chunk.js new file mode 100644 index 000000000000..8c888eb69e87 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42791.26100ebe.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42791],{37854:e=>{function t(e){e.languages.peoplecode={comment:RegExp([/\/\*[\s\S]*?\*\//.source,/\bREM[^;]*;/.source,/<\*(?:[^<*]|\*(?!>)|<(?!\*)|<\*(?:(?!\*>)[\s\S])*\*>)*\*>/.source,/\/\+[\s\S]*?\+\//.source].join("|")),string:{pattern:/'(?:''|[^'\r\n])*'(?!')|"(?:""|[^"\r\n])*"(?!")/,greedy:!0},variable:/%\w+/,"function-definition":{pattern:/((?:^|[^\w-])(?:function|method)\s+)\w+/i,lookbehind:!0,alias:"function"},"class-name":{pattern:/((?:^|[^-\w])(?:as|catch|class|component|create|extends|global|implements|instance|local|of|property|returns)\s+)\w+(?::\w+)*/i,lookbehind:!0,inside:{punctuation:/:/}},keyword:/\b(?:abstract|alias|as|catch|class|component|constant|create|declare|else|end-(?:class|evaluate|for|function|get|if|method|set|try|while)|evaluate|extends|for|function|get|global|if|implements|import|instance|library|local|method|null|of|out|peopleCode|private|program|property|protected|readonly|ref|repeat|returns?|set|step|then|throw|to|try|until|value|when(?:-other)?|while)\b/i,"operator-keyword":{pattern:/\b(?:and|not|or)\b/i,alias:"operator"},function:/[_a-z]\w*(?=\s*\()/i,boolean:/\b(?:false|true)\b/i,number:/\b\d+(?:\.\d+)?\b/,operator:/<>|[<>]=?|!=|\*\*|[-+*/|=@]/,punctuation:/[:.;,()[\]]/},e.languages.pcode=e.languages.peoplecode}e.exports=t,t.displayName="peoplecode",t.aliases=["pcode"]},42791:(e,t,o)=>{o.d(t,{default:()=>n});var a=o(37854);const n=o.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/42912.7ab36c78.chunk.js b/ydb/core/viewer/monitoring/static/js/42912.7ab36c78.chunk.js new file mode 100644 index 000000000000..d5c8cefff1fb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/42912.7ab36c78.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[42912],{34363:(e,n,t)=>{var a=t(76064),o=t(51572);function r(e){e.register(a),e.register(o),function(e){e.languages.etlua={delimiter:{pattern:/^<%[-=]?|-?%>$/,alias:"punctuation"},"language-lua":{pattern:/[\s\S]+/,inside:e.languages.lua}},e.hooks.add("before-tokenize",(function(n){e.languages["markup-templating"].buildPlaceholders(n,"etlua",/<%[\s\S]+?%>/g)})),e.hooks.add("after-tokenize",(function(n){e.languages["markup-templating"].tokenizePlaceholders(n,"etlua")}))}(e)}e.exports=r,r.displayName="etlua",r.aliases=[]},42912:(e,n,t)=>{t.d(n,{default:()=>o});var a=t(34363);const o=t.n(a)()},51572:e=>{function n(e){!function(e){function n(e,n){return"___"+e.toUpperCase()+n+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,a,o,r){if(t.language===a){var i=t.tokenStack=[];t.code=t.code.replace(o,(function(e){if("function"===typeof r&&!r(e))return e;for(var o,l=i.length;-1!==t.code.indexOf(o=n(a,l));)++l;return i[l]=e,o})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,a){if(t.language===a&&t.tokenStack){t.grammar=e.languages[a];var o=0,r=Object.keys(t.tokenStack);!function i(l){for(var u=0;u=r.length);u++){var s=l[u];if("string"===typeof s||s.content&&"string"===typeof s.content){var g=r[o],c=t.tokenStack[g],d="string"===typeof s?s:s.content,p=n(a,g),f=d.indexOf(p);if(f>-1){++o;var k=d.substring(0,f),b=new e.Token(a,e.tokenize(c,t.grammar),"language-"+a,c),m=d.substring(f+p.length),h=[];k&&h.push.apply(h,i([k])),h.push(b),m&&h.push.apply(h,i([m])),"string"===typeof s?l.splice.apply(l,[u,1].concat(h)):s.content=h}}else s.content&&i(s.content)}return l}(t.tokens)}}}})}(e)}e.exports=n,n.displayName="markupTemplating",n.aliases=[]},76064:e=>{function n(e){e.languages.lua={comment:/^#!.+|--(?:\[(=*)\[[\s\S]*?\]\1\]|.*)/m,string:{pattern:/(["'])(?:(?!\1)[^\\\r\n]|\\z(?:\r\n|\s)|\\(?:\r\n|[^z]))*\1|\[(=*)\[[\s\S]*?\]\2\]/,greedy:!0},number:/\b0x[a-f\d]+(?:\.[a-f\d]*)?(?:p[+-]?\d+)?\b|\b\d+(?:\.\B|(?:\.\d*)?(?:e[+-]?\d+)?\b)|\B\.\d+(?:e[+-]?\d+)?\b/i,keyword:/\b(?:and|break|do|else|elseif|end|false|for|function|goto|if|in|local|nil|not|or|repeat|return|then|true|until|while)\b/,function:/(?!\d)\w+(?=\s*(?:[({]))/,operator:[/[-+*%^&|#]|\/\/?|<[<=]?|>[>=]?|[=~]=?/,{pattern:/(^|[^.])\.\.(?!\.)/,lookbehind:!0}],punctuation:/[\[\](){},;]|\.+|:+/}}e.exports=n,n.displayName="lua",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/43028.3817b0d7.chunk.js b/ydb/core/viewer/monitoring/static/js/43028.3817b0d7.chunk.js new file mode 100644 index 000000000000..55ec0bb47769 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/43028.3817b0d7.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[43028],{11641:n=>{function e(n){!function(n){var e=/(?:\\.|[^\\\n\r]|(?:\n|\r\n?)(?![\r\n]))/.source;function t(n){return n=n.replace(//g,(function(){return e})),RegExp(/((?:^|[^\\])(?:\\{2})*)/.source+"(?:"+n+")")}var a=/(?:\\.|``(?:[^`\r\n]|`(?!`))+``|`[^`\r\n]+`|[^\\|\r\n`])+/.source,r=/\|?__(?:\|__)+\|?(?:(?:\n|\r\n?)|(?![\s\S]))/.source.replace(/__/g,(function(){return a})),i=/\|?[ \t]*:?-{3,}:?[ \t]*(?:\|[ \t]*:?-{3,}:?[ \t]*)+\|?(?:\n|\r\n?)/.source;n.languages.markdown=n.languages.extend("markup",{}),n.languages.insertBefore("markdown","prolog",{"front-matter-block":{pattern:/(^(?:\s*[\r\n])?)---(?!.)[\s\S]*?[\r\n]---(?!.)/,lookbehind:!0,greedy:!0,inside:{punctuation:/^---|---$/,"front-matter":{pattern:/\S+(?:\s+\S+)*/,alias:["yaml","language-yaml"],inside:n.languages.yaml}}},blockquote:{pattern:/^>(?:[\t ]*>)*/m,alias:"punctuation"},table:{pattern:RegExp("^"+r+i+"(?:"+r+")*","m"),inside:{"table-data-rows":{pattern:RegExp("^("+r+i+")(?:"+r+")*$"),lookbehind:!0,inside:{"table-data":{pattern:RegExp(a),inside:n.languages.markdown},punctuation:/\|/}},"table-line":{pattern:RegExp("^("+r+")"+i+"$"),lookbehind:!0,inside:{punctuation:/\||:?-{3,}:?/}},"table-header-row":{pattern:RegExp("^"+r+"$"),inside:{"table-header":{pattern:RegExp(a),alias:"important",inside:n.languages.markdown},punctuation:/\|/}}}},code:[{pattern:/((?:^|\n)[ \t]*\n|(?:^|\r\n?)[ \t]*\r\n?)(?: {4}|\t).+(?:(?:\n|\r\n?)(?: {4}|\t).+)*/,lookbehind:!0,alias:"keyword"},{pattern:/^```[\s\S]*?^```$/m,greedy:!0,inside:{"code-block":{pattern:/^(```.*(?:\n|\r\n?))[\s\S]+?(?=(?:\n|\r\n?)^```$)/m,lookbehind:!0},"code-language":{pattern:/^(```).+/,lookbehind:!0},punctuation:/```/}}],title:[{pattern:/\S.*(?:\n|\r\n?)(?:==+|--+)(?=[ \t]*$)/m,alias:"important",inside:{punctuation:/==+$|--+$/}},{pattern:/(^\s*)#.+/m,lookbehind:!0,alias:"important",inside:{punctuation:/^#+|#+$/}}],hr:{pattern:/(^\s*)([*-])(?:[\t ]*\2){2,}(?=\s*$)/m,lookbehind:!0,alias:"punctuation"},list:{pattern:/(^\s*)(?:[*+-]|\d+\.)(?=[\t ].)/m,lookbehind:!0,alias:"punctuation"},"url-reference":{pattern:/!?\[[^\]]+\]:[\t ]+(?:\S+|<(?:\\.|[^>\\])+>)(?:[\t ]+(?:"(?:\\.|[^"\\])*"|'(?:\\.|[^'\\])*'|\((?:\\.|[^)\\])*\)))?/,inside:{variable:{pattern:/^(!?\[)[^\]]+/,lookbehind:!0},string:/(?:"(?:\\.|[^"\\])*"|'(?:\\.|[^'\\])*'|\((?:\\.|[^)\\])*\))$/,punctuation:/^[\[\]!:]|[<>]/},alias:"url"},bold:{pattern:t(/\b__(?:(?!_)|_(?:(?!_))+_)+__\b|\*\*(?:(?!\*)|\*(?:(?!\*))+\*)+\*\*/.source),lookbehind:!0,greedy:!0,inside:{content:{pattern:/(^..)[\s\S]+(?=..$)/,lookbehind:!0,inside:{}},punctuation:/\*\*|__/}},italic:{pattern:t(/\b_(?:(?!_)|__(?:(?!_))+__)+_\b|\*(?:(?!\*)|\*\*(?:(?!\*))+\*\*)+\*/.source),lookbehind:!0,greedy:!0,inside:{content:{pattern:/(^.)[\s\S]+(?=.$)/,lookbehind:!0,inside:{}},punctuation:/[*_]/}},strike:{pattern:t(/(~~?)(?:(?!~))+\2/.source),lookbehind:!0,greedy:!0,inside:{content:{pattern:/(^~~?)[\s\S]+(?=\1$)/,lookbehind:!0,inside:{}},punctuation:/~~?/}},"code-snippet":{pattern:/(^|[^\\`])(?:``[^`\r\n]+(?:`[^`\r\n]+)*``(?!`)|`[^`\r\n]+`(?!`))/,lookbehind:!0,greedy:!0,alias:["code","keyword"]},url:{pattern:t(/!?\[(?:(?!\]))+\](?:\([^\s)]+(?:[\t ]+"(?:\\.|[^"\\])*")?\)|[ \t]?\[(?:(?!\]))+\])/.source),lookbehind:!0,greedy:!0,inside:{operator:/^!/,content:{pattern:/(^\[)[^\]]+(?=\])/,lookbehind:!0,inside:{}},variable:{pattern:/(^\][ \t]?\[)[^\]]+(?=\]$)/,lookbehind:!0},url:{pattern:/(^\]\()[^\s)]+/,lookbehind:!0},string:{pattern:/(^[ \t]+)"(?:\\.|[^"\\])*"(?=\)$)/,lookbehind:!0}}}}),["url","bold","italic","strike"].forEach((function(e){["url","bold","italic","strike","code-snippet"].forEach((function(t){e!==t&&(n.languages.markdown[e].inside.content.inside[t]=n.languages.markdown[t])}))})),n.hooks.add("after-tokenize",(function(n){"markdown"!==n.language&&"md"!==n.language||function n(e){if(e&&"string"!==typeof e)for(var t=0,a=e.length;t",quot:'"'},s=String.fromCodePoint||String.fromCharCode;n.languages.md=n.languages.markdown}(n)}n.exports=e,e.displayName="markdown",e.aliases=["md"]},43028:(n,e,t)=>{t.d(e,{default:()=>r});var a=t(11641);const r=t.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4324.c69948f7.chunk.js b/ydb/core/viewer/monitoring/static/js/4324.c69948f7.chunk.js deleted file mode 100644 index 42b86055b4dc..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4324.c69948f7.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4324],{74324:function(e,_,s){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var s=_(e),o={name:"es-pr",monthsShort:"ene_feb_mar_abr_may_jun_jul_ago_sep_oct_nov_dic".split("_"),weekdays:"domingo_lunes_martes_mi\xe9rcoles_jueves_viernes_s\xe1bado".split("_"),weekdaysShort:"dom._lun._mar._mi\xe9._jue._vie._s\xe1b.".split("_"),weekdaysMin:"do_lu_ma_mi_ju_vi_s\xe1".split("_"),months:"enero_febrero_marzo_abril_mayo_junio_julio_agosto_septiembre_octubre_noviembre_diciembre".split("_"),weekStart:1,formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"MM/DD/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY h:mm A",LLLL:"dddd, D [de] MMMM [de] YYYY h:mm A"},relativeTime:{future:"en %s",past:"hace %s",s:"unos segundos",m:"un minuto",mm:"%d minutos",h:"una hora",hh:"%d horas",d:"un d\xeda",dd:"%d d\xedas",M:"un mes",MM:"%d meses",y:"un a\xf1o",yy:"%d a\xf1os"},ordinal:function(e){return e+"\xba"}};return s.default.locale(o,null,!0),o}(s(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/43334.53a7ed5d.chunk.js b/ydb/core/viewer/monitoring/static/js/43334.53a7ed5d.chunk.js new file mode 100644 index 000000000000..061e1d4773f0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/43334.53a7ed5d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[43334],{9252:(e,t,a)=>{a.d(t,{k:()=>l});var r=a(44433),n=a(88610),o=a(60712);const l=({value:e,onChange:t,className:a})=>(0,o.jsxs)(r.a,{value:e,onUpdate:t,className:a,children:[(0,o.jsx)(r.a.Option,{value:n.s$.ALL,children:n.s$.ALL}),(0,o.jsx)(r.a.Option,{value:n.s$.PROBLEMS,children:n.s$.PROBLEMS})]})},11363:(e,t,a)=>{a.d(t,{G:()=>oe});var r=a(59284),n=a(86782),o=a(12888),l=a(98167),s=a(67028),i=a(90182),d=a(88610);function u(){const e=(0,i.YQ)();return{problemFilter:(0,i.N4)(d.yV),handleProblemFilterChange:t=>{e((0,d.$u)(t))}}}var c=a(78034),p=a(80987),h=a(48372);const m=JSON.parse('{"nodes":"Nodes","empty.default":"No such nodes","no-nodes-groups":"No nodes groups","controls_search-placeholder":"Host name","controls_group-by-placeholder":"Group by:","controls_peer-role-label":"Peer role:","database":"database","static":"static","other":"other","any":"any"}'),g=(0,h.g4)("ydb-nodes",{en:m}),b=["database","static","other","any"],y={get database(){return g("database")},get static(){return g("static")},get other(){return g("other")},get any(){return g("any")}};const v="nodesTableSelectedColumns",f=["NodeId","Host","Uptime","CPU","RAM","Version","Tablets"],x=["NodeId"],C=["SystemState","Host","DC","Rack","Database","Version","Uptime"];function w(e,t){return t?e:e.filter((e=>"SystemState"!==e))}function j(e){var t;const[a,r]=(0,p.useQueryParams)({uptimeFilter:p.StringParam,peerRole:p.StringParam,search:p.StringParam,nodesGroupBy:p.StringParam}),n=c.Bm.parse(a.uptimeFilter),o=null!==(t=a.search)&&void 0!==t?t:"",l=(i=a.peerRole,b.find((e=>e===i)));var i;const d=(0,s.DM)(),u=function(e,t,a){return w(t,a).find((t=>t===e))}(a.nodesGroupBy,null!==e&&void 0!==e?e:[],d);return{uptimeFilter:n,searchValue:o,peerRoleFilter:l,groupByParam:u,handleSearchQueryChange:e=>{r({search:e||void 0},"replaceIn")},handleUptimeFilterChange:e=>{r({uptimeFilter:e},"replaceIn")},handlePeerRoleFilterChange:e=>{r({peerRole:e},"replaceIn")},handleGroupByParamChange:e=>{r({nodesGroupBy:e},"replaceIn")}}}var N=a(44508),S=a(42265),T=a(15298),F=a(43951),I=a(71708),P=a(62710),R=a(98089),B=a(69775),A=a(24555),_=a(28539),k=a(9252),G=a(95963),E=a(64934),D=a(44433),L=a(60712);function q({value:e="database",onChange:t}){return(0,L.jsx)(D.a,{value:e,onUpdate:t,children:b.map((e=>(0,L.jsx)(D.a.Option,{value:e,children:y[e]},e)))})}const O=(0,a(77506).cn)("ydb-nodes"),U=e=>O("node",{unavailable:(0,c.X7)(e)});function V({withGroupBySelect:e,groupByParams:t=[],withPeerRoleFilter:a,columnsToSelect:o,handleSelectedColumnsUpdate:l,entitiesCountCurrent:i,entitiesCountTotal:d,entitiesLoading:c}){const{searchValue:p,uptimeFilter:h,peerRoleFilter:m,groupByParam:b,handleSearchQueryChange:y,handleUptimeFilterChange:v,handlePeerRoleFilterChange:f,handleGroupByParamChange:x}=j(t),{problemFilter:C,handleProblemFilterChange:N}=u(),S=(0,s.DM)(),T=function(e,t){return w(e,t).map((e=>({value:e,content:(0,n.kn)(e)})))}(t,S),F=(0,s.WF)(),I=a&&F;return(0,L.jsxs)(r.Fragment,{children:[(0,L.jsx)(G.v,{onChange:y,placeholder:g("controls_search-placeholder"),width:238,value:p}),S&&e?null:(0,L.jsx)(k.k,{value:C,onChange:N}),e?null:(0,L.jsx)(E.j,{value:h,onChange:v}),I?(0,L.jsxs)(r.Fragment,{children:[(0,L.jsx)(R.E,{variant:"body-2",children:g("controls_peer-role-label")}),(0,L.jsx)(q,{value:m,onChange:f})]}):null,(0,L.jsx)(B.O,{popupWidth:200,items:o,showStatus:!0,onUpdate:l,sortable:!1}),e?(0,L.jsxs)(r.Fragment,{children:[(0,L.jsx)(R.E,{variant:"body-2",children:g("controls_group-by-placeholder")}),(0,L.jsx)(A.l,{hasClear:!0,placeholder:"-",width:150,defaultValue:b?[b]:void 0,onUpdate:e=>{x(e[0])},options:T,className:O("group-by-select"),popupClassName:O("group-by-popup")})]}):null,(0,L.jsx)(_.T,{current:i,total:d,label:g("nodes"),loading:c})]})}var H=a(78524),$=a(40427),M=a(81101),Q=a(11906),W=a(69464),K=a(40781);const X=async e=>{const{type:t="any",storage:a=!1,tablets:r=!0,limit:o,offset:l,sortParams:s,filters:i,columnsIds:d}=e,{sortOrder:u,columnId:p}=null!==s&&void 0!==s?s:{},{path:h,database:m,searchValue:g,problemFilter:b,uptimeFilter:y,peerRoleFilter:v,filterGroup:f,filterGroupBy:x}=null!==i&&void 0!==i?i:{},C=(0,n.kU)(p),w=C?(0,W.T)(C,u):void 0,j=(0,K.R)(d,n.fN),N=await window.api.viewer.getNodes({type:t,storage:a,tablets:r,limit:o,offset:l,sort:w,path:h,database:m,filter:g,problems_only:(0,c.AB)(b),uptime:(0,c.Fo)(y),filter_peer_role:v,filter_group:f,filter_group_by:x,fieldsRequired:j}),S=(0,Q.N)(N);return{data:S.Nodes||[],found:S.FoundNodes||0,total:S.TotalNodes||0}};function J({path:e,database:t,searchValue:a,problemFilter:o,uptimeFilter:l,peerRoleFilter:s,filterGroup:i,filterGroupBy:d,columns:u,scrollContainerRef:p,initialEntitiesCount:h}){const m=r.useMemo((()=>({path:e,database:t,searchValue:a,problemFilter:o,uptimeFilter:l,peerRoleFilter:s,filterGroup:i,filterGroupBy:d})),[e,t,a,o,l,s,i,d]);return(0,L.jsx)($.k5,{columnsWidthLSKey:n.zO,scrollContainerRef:p,columns:u,fetchData:X,initialEntitiesCount:h,renderErrorMessage:M.$,renderEmptyDataMessage:()=>"All"!==o||l!==c.cW.All?(0,L.jsx)(H.v,{name:"thumbsUp",width:"200"}):g("empty.default"),getRowClassName:U,filters:m,tableName:"nodes"})}const z=r.memo((function({name:e,count:t,isExpanded:a,path:r,database:n,searchValue:o,peerRoleFilter:l,groupByParam:s,columns:i,scrollContainerRef:d,onIsExpandedChange:u}){return(0,L.jsx)(I.Q,{title:e,count:t,entityName:g("nodes"),expanded:a,onIsExpandedChange:u,children:(0,L.jsx)(J,{path:r,database:n,searchValue:o,problemFilter:"All",uptimeFilter:c.cW.All,peerRoleFilter:l,filterGroup:e,filterGroupBy:s,initialEntitiesCount:t,columns:i,scrollContainerRef:d})},e)}));function Y({path:e,database:t,scrollContainerRef:a,withPeerRoleFilter:o,columns:l,defaultColumnsIds:s,requiredColumnsIds:d,selectedColumnsKey:u,groupByParams:c}){const{searchValue:p,peerRoleFilter:h,groupByParam:m}=j(c),[b]=(0,i.Nt)(),{columnsToShow:y,columnsToSelect:v,setColumns:f}=(0,F.K)(l,u,n.uG,s,d),{currentData:x,isFetching:C,error:w}=T.s.useGetNodesQuery({path:e,database:t,filter:p,filter_peer_role:h,group:m,limit:0},{pollingInterval:b}),I=void 0===x&&C,{NodeGroups:R,FoundNodes:B=0,TotalNodes:A=0}=x||{},{expandedGroups:_,setIsGroupExpanded:k}=(0,P.$)(R),G=r.useMemo((()=>({foundEntities:B,totalEntities:A,isInitialLoad:I,sortParams:void 0})),[B,A,I]);return(0,L.jsx)(S.o,{initialState:G,controls:(0,L.jsx)(V,{groupByParams:c,withPeerRoleFilter:o,columnsToSelect:v,handleSelectedColumnsUpdate:f,entitiesCountCurrent:B,entitiesCountTotal:A,entitiesLoading:I,withGroupBySelect:!0}),error:w?(0,L.jsx)(N.o,{error:w}):null,table:null!==R&&void 0!==R&&R.length?R.map((({name:r,count:n})=>{const o=_[r];return(0,L.jsx)(z,{name:r,count:n,isExpanded:o,path:e,database:t,searchValue:p,peerRoleFilter:h,groupByParam:m,columns:y,scrollContainerRef:a,onIsExpandedChange:k},r)})):g("no-nodes-groups"),tableProps:{scrollContainerRef:a,scrollDependencies:[p,m,R,h],loading:I,className:O("groups-wrapper")},fullHeight:!0})}var Z=a(49554);function ee({withGroupBySelect:e,groupByParams:t,withPeerRoleFilter:a,columnsToSelect:r,handleSelectedColumnsUpdate:n}){const{tableState:o}=(0,Z.WV)();return(0,L.jsx)(V,{withGroupBySelect:e,groupByParams:t,withPeerRoleFilter:a,columnsToSelect:r,handleSelectedColumnsUpdate:n,entitiesCountCurrent:o.foundEntities,entitiesCountTotal:o.totalEntities,entitiesLoading:o.isInitialLoad})}function te({path:e,database:t,scrollContainerRef:a,withPeerRoleFilter:r,columns:o,defaultColumnsIds:l,requiredColumnsIds:i,selectedColumnsKey:d,groupByParams:c}){const{searchValue:p,uptimeFilter:h,peerRoleFilter:m}=j(c),{problemFilter:g}=u(),b=(0,s.Ye)(),{columnsToShow:y,columnsToSelect:v,setColumns:f}=(0,F.K)(o,d,n.uG,l,i);return(0,L.jsx)(S.o,{controls:(0,L.jsx)(ee,{withGroupBySelect:b,groupByParams:c,withPeerRoleFilter:r,columnsToSelect:v,handleSelectedColumnsUpdate:f}),table:(0,L.jsx)(J,{path:e,database:t,searchValue:p,problemFilter:g,uptimeFilter:h,peerRoleFilter:m,columns:y,scrollContainerRef:a}),tableProps:{scrollContainerRef:a,scrollDependencies:[p,g,h,m]},fullHeight:!0})}function ae(e){const{uptimeFilter:t,groupByParam:a,handleUptimeFilterChange:n}=j(e.groupByParams),{problemFilter:o,handleProblemFilterChange:i}=u(),d=(0,s.Pm)(),p=(0,s.Ye)();r.useEffect((()=>{!p||"All"===o&&t===c.cW.All||(i("All"),n(c.cW.All))}),[i,n,o,t,p]);return(0,L.jsx)(l.r,{loading:!d,children:p&&a?(0,L.jsx)(Y,{...e}):(0,L.jsx)(te,{...e})})}var re=a(78762);function ne(e){return[(0,re._E)(),(0,re.Nh)(e),(0,re.eT)(),(0,re.uk)(),(0,re.OX)(),(0,re.jl)(),(0,re.fr)(),(0,re.kv)(),(0,re.pH)(),(0,re.iX)(),(0,re.ID)(),(0,re.Rn)(),(0,re.qp)(e)].map((e=>({...e,sortable:(0,n.sp)(e.name)})))}function oe({path:e,database:t,scrollContainerRef:a,additionalNodesProps:l,withPeerRoleFilter:s,columns:i=ne({database:t,getNodeRef:null===l||void 0===l?void 0:l.getNodeRef}),defaultColumnsIds:d=f,requiredColumnsIds:u=x,selectedColumnsKey:c=v,groupByParams:p=C}){const h=(0,o.X)(),m=r.useMemo((()=>h?i:i.filter((e=>!(0,n.xd)(e.name)))),[i,h]);return(0,L.jsx)(ae,{path:e,database:t,scrollContainerRef:a,withPeerRoleFilter:s,columns:m,defaultColumnsIds:d,requiredColumnsIds:u,selectedColumnsKey:c,groupByParams:p})}},11906:(e,t,a)=>{a.d(t,{N:()=>n});var r=a(78034);const n=e=>{var t;const a=(e.Nodes||[]).map((e=>{const{SystemState:t,...a}=e;return{...a,...(0,r.q1)(t)}}));return{Nodes:a,NodeGroups:null===(t=e.NodeGroups)||void 0===t?void 0:t.map((({GroupName:e,NodeCount:t})=>{if(e&&t)return{name:e,count:Number(t)}})).filter((e=>Boolean(e))),TotalNodes:Number(e.TotalNodes)||a.length,FoundNodes:Number(e.FoundNodes)}}},15298:(e,t,a)=>{a.d(t,{s:()=>o});var r=a(21334),n=a(11906);const o=r.F.injectEndpoints({endpoints:e=>({getNodes:e.query({queryFn:async(e,{signal:t})=>{try{const a=await window.api.viewer.getNodes({type:"any",storage:!1,tablets:!0,...e},{signal:t});return{data:(0,n.N)(a)}}catch(a){return{error:a}}},providesTags:["All"]})}),overrideExisting:"throw"})},21545:(e,t,a)=>{a.d(t,{X:()=>n});var r=a(78034);const n=a(21334).F.injectEndpoints({endpoints:e=>({getTablet:e.query({queryFn:async({id:e,database:t,followerId:a},{signal:n})=>{try{const[o,l,s]=await Promise.all([window.api.viewer.getTablet({id:e,database:t,followerId:a},{signal:n}),window.api.viewer.getTabletHistory({id:e,database:t},{signal:n}),window.api.viewer.getNodesList({signal:n})]),i=(0,r.nN)(s),d=Object.keys(l).reduce(((e,t)=>{var a;const r=null===(a=l[t])||void 0===a?void 0:a.TabletStateInfo;return null===r||void 0===r||r.forEach((a=>{var r;const{ChangeTime:n,Generation:o,State:l,Leader:s,FollowerId:d}=a,u=i&&t?null===(r=i.get(Number(t)))||void 0===r?void 0:r.Host:void 0;e.push({nodeId:t,generation:o,changeTime:n,state:l,leader:s,followerId:d,fqdn:u})})),e}),[]),{TabletStateInfo:u=[]}=o,c=void 0===a?u.find((e=>e.Leader)):u.find((e=>{var t;return(null===(t=e.FollowerId)||void 0===t?void 0:t.toString())===a})),{TabletId:p}=c||{};return{data:{id:p,data:c,history:d}}}catch(o){return{error:o}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),getTabletDescribe:e.query({queryFn:async({tenantId:e},{signal:t})=>{try{const a=await window.api.viewer.getTabletDescribe(e,{signal:t}),{SchemeShard:r,PathId:n}=e;return{data:(null===a||void 0===a?void 0:a.Path)||`${r}:${n}`}}catch(a){return{error:a}}},providesTags:["All"]}),getAdvancedTableInfo:e.query({queryFn:async({id:e,hiveId:t},{signal:a})=>{try{return{data:await window.api.tablets.getTabletFromHive({id:e,hiveId:t},{signal:a})}}catch(r){return{error:r}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),killTablet:e.mutation({queryFn:async({id:e})=>{try{return{data:await window.api.tablets.killTablet(e)}}catch(t){return{error:t}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),stopTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.stopTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),resumeTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.resumeTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"})},22983:(e,t,a)=>{a.d(t,{B:()=>d});var r=a(59284),n=a(84476),o=a(84375),l=a(55974),s=a(42829),i=a(60712);function d({children:e,onConfirmAction:t,onConfirmActionSuccess:a,dialogHeader:d,dialogText:u,retryButtonText:c,buttonDisabled:p=!1,buttonView:h="action",buttonTitle:m,buttonClassName:g,withPopover:b=!1,popoverContent:y,popoverPlacement:v="right",popoverDisabled:f=!0}){const[x,C]=r.useState(!1),[w,j]=r.useState(!1),[N,S]=r.useState(!1),T=()=>(0,i.jsx)(n.$,{onClick:()=>C(!0),view:h,disabled:p,loading:!p&&w,className:g,title:m,children:e});return(0,i.jsxs)(r.Fragment,{children:[(0,i.jsx)(l.g,{visible:x,header:d,text:u,withRetry:N,retryButtonText:c,onConfirm:async e=>{j(!0),await t(e)},onConfirmActionSuccess:async()=>{S(!1);try{await(null===a||void 0===a?void 0:a())}finally{j(!1)}},onConfirmActionError:e=>{S((0,s.D)(e)),j(!1)},onClose:()=>{C(!1)}}),b?(0,i.jsx)(o.A,{content:y,placement:v,disabled:f,children:T()}):T()]})}},27775:(e,t,a)=>{a.d(t,{i:()=>l});var r=a(47665),n=a(58267),o=a(60712);function l({state:e}){return(0,o.jsx)(r.J,{theme:(0,n._)(e),children:e})}},28539:(e,t,a)=>{a.d(t,{T:()=>r.T});var r=a(53755)},42829:(e,t,a)=>{a.d(t,{D:()=>r});const r=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},55974:(e,t,a)=>{a.d(t,{g:()=>v});var r=a(59284),n=a(18677),o=a(71153),l=a(74321),s=a(2198),i=a(99991),d=a(56999),u=a(77506),c=a(81288),p=a(48372);const h=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),m=(0,p.g4)("ydb-critical-action-dialog",{en:h});var g=a(60712);const b=(0,u.cn)("ydb-critical-dialog"),y=e=>{if((0,c.cH)(e)){if(403===e.status)return m("no-rights-error");if("string"===typeof e.data)return e.data;if((0,c._E)(e)&&e.data)return(0,g.jsx)(d.O,{hideSeverity:!0,data:e.data});if(e.statusText)return e.statusText}return m("default-error")};function v({visible:e,header:t,text:a,withRetry:d,retryButtonText:u,withCheckBox:c,onClose:p,onConfirm:h,onConfirmActionSuccess:v,onConfirmActionError:f}){const[x,C]=r.useState(!1),[w,j]=r.useState(),[N,S]=r.useState(!1),T=async e=>(C(!0),h(e).then((()=>{v(),p()})).catch((e=>{f(e),j(e)})).finally((()=>{C(!1)})));return(0,g.jsx)(s.l,{open:e,hasCloseButton:!1,className:b(),size:"s",onClose:p,onTransitionExited:()=>{j(void 0),S(!1)},children:w?(0,g.jsxs)(r.Fragment,{children:[(0,g.jsx)(s.l.Header,{caption:t}),(0,g.jsx)(s.l.Body,{className:b("body"),children:(0,g.jsxs)("div",{className:b("body-message",{error:!0}),children:[(0,g.jsx)("span",{className:b("error-icon"),children:(0,g.jsx)(n.A,{width:"24",height:"22"})}),y(w)]})}),(0,g.jsx)(s.l.Footer,{loading:!1,preset:"default",textButtonApply:d?u||m("button-retry"):void 0,textButtonCancel:m("button-close"),onClickButtonApply:()=>T(!0),onClickButtonCancel:p})]}):(0,g.jsxs)(r.Fragment,{children:[(0,g.jsx)(s.l.Header,{caption:t}),(0,g.jsxs)(s.l.Body,{className:b("body"),children:[(0,g.jsxs)("div",{className:b("body-message",{warning:!0}),children:[(0,g.jsx)("span",{className:b("warning-icon"),children:(0,g.jsx)(i.I,{data:o.A,size:24})}),a]}),c?(0,g.jsx)(l.S,{checked:N,onUpdate:S,children:m("checkbox-text")}):null]}),(0,g.jsx)(s.l.Footer,{loading:x,preset:"default",textButtonApply:m("button-confirm"),textButtonCancel:m("button-cancel"),propsButtonApply:{type:"submit",disabled:c&&!N},onClickButtonCancel:p,onClickButtonApply:()=>T()})]})})}},56999:(e,t,a)=>{a.d(t,{O:()=>C});var r=a(59284),n=a(45720),o=a(16929),l=a(71153),s=a(18677),i=a(84476),d=a(33705),u=a(67884),c=a(99991),p=a(74529),h=a(77506),m=a(41650);const g=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function b(e){return function(e){return!!e&&void 0!==g[e]}(e)?g[e]:"S_INFO"}var y=a(60712);const v=(0,h.cn)("kv-result-issues"),f=(0,h.cn)("kv-issues"),x=(0,h.cn)("kv-issue");function C({data:e,hideSeverity:t}){const[a,n]=r.useState(!1),o="string"===typeof e||null===e||void 0===e?void 0:e.issues,l=Array.isArray(o)&&o.length>0;return(0,y.jsxs)("div",{className:v(),children:[(0,y.jsxs)("div",{className:v("error-message"),children:[(()=>{let a;if("string"===typeof e)a=e;else{var n,o;const l=b(null===e||void 0===e||null===(n=e.error)||void 0===n?void 0:n.severity);a=(0,y.jsxs)(r.Fragment,{children:[t?null:(0,y.jsxs)(r.Fragment,{children:[(0,y.jsx)(I,{severity:l})," "]}),(0,y.jsx)("span",{className:v("error-message-text"),children:null===e||void 0===e||null===(o=e.error)||void 0===o?void 0:o.message})]})}return a})(),l&&(0,y.jsx)(i.$,{view:"normal",onClick:()=>n(!a),children:a?"Hide details":"Show details"})]}),l&&a&&(0,y.jsx)(w,{hideSeverity:t,issues:o})]})}function w({issues:e,hideSeverity:t}){const a=null===e||void 0===e?void 0:e.reduce(((e,t)=>{var a;const r=null!==(a=t.severity)&&void 0!==a?a:10;return Math.min(e,r)}),10);return(0,y.jsx)("div",{className:f(null),children:null===e||void 0===e?void 0:e.map(((e,r)=>(0,y.jsx)(j,{hideSeverity:t,issue:e,expanded:e===a},r)))})}function j({issue:e,hideSeverity:t,level:a=0}){const[n,o]=r.useState(!0),l=b(e.severity),s=e.issues,u=Array.isArray(s)&&s.length>0,c=n?"bottom":"right";return(0,y.jsxs)("div",{className:x({leaf:!u,"has-issues":u}),children:[(0,y.jsxs)("div",{className:x("line"),children:[u&&(0,y.jsx)(i.$,{view:"flat-secondary",onClick:()=>o(!n),className:x("arrow-toggle"),children:(0,y.jsx)(d.I,{direction:c,size:16})}),t?null:(0,y.jsx)(I,{severity:l}),(0,y.jsx)(N,{issue:e}),e.issue_code?(0,y.jsxs)("span",{className:x("code"),children:["Code: ",e.issue_code]}):null]}),u&&n&&(0,y.jsx)("div",{className:x("issues"),children:(0,y.jsx)(S,{issues:s,level:a+1,expanded:n})})]})}function N({issue:e}){var t;const a=function(e){const{position:t}=e;if("object"!==typeof t||null===t||!(0,m.kf)(t.row))return"";const{row:a,column:r}=t;return(0,m.kf)(r)?`${a}:${r}`:`line ${a}`}(e),r=window.ydbEditor,n=()=>(0,y.jsxs)("span",{className:x("message"),children:[a&&(0,y.jsx)("span",{className:x("place-text"),title:"Position",children:a}),(0,y.jsx)("div",{className:x("message-text"),children:(0,y.jsx)(p.A,{value:e.message,expandLabel:"Show full message"})})]}),{row:o,column:l}=null!==(t=e.position)&&void 0!==t?t:{};if(!((0,m.kf)(o)&&r))return n();return(0,y.jsx)(u.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:o,column:null!==l&&void 0!==l?l:0};r.setPosition(e),r.revealPositionInCenterIfOutsideViewport(e),r.focus()},view:"primary",children:n()})}function S(e){const{issues:t,level:a,expanded:r}=e;return(0,y.jsx)("div",{className:x("list"),children:t.map(((e,t)=>(0,y.jsx)(j,{issue:e,level:a,expanded:r},t)))})}const T={S_INFO:n.A,S_WARNING:o.A,S_ERROR:l.A,S_FATAL:s.A},F=(0,h.cn)("yql-issue-severity");function I({severity:e}){const t=e.slice(2).toLowerCase();return(0,y.jsxs)("span",{className:F({severity:t}),children:[(0,y.jsx)(c.I,{className:F("icon"),data:T[e]}),(0,y.jsx)("span",{className:F("title"),children:t})]})}},74529:(e,t,a)=>{a.d(t,{A:()=>p});var r=a(59284),n=a(67884),o=a(77506),l=a(48372);const s=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),i=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),d=(0,l.g4)("ydb-shorty-string",{ru:i,en:s});var u=a(60712);const c=(0,o.cn)("kv-shorty-string");function p({value:e="",limit:t=200,strict:a=!1,displayLength:o=!0,render:l=e=>e,onToggle:s,expandLabel:i=d("default_expand_label"),collapseLabel:p=d("default_collapse_label")}){const[h,m]=r.useState(!1),g=(h?p:i)+(o&&!h?d("chars_count",{count:e.length}):""),b=e.length>t+(a?0:g.length),y=h||!b?e:e.slice(0,t-4)+"\xa0...";return(0,u.jsxs)("div",{className:c(),children:[l(y),b?(0,u.jsx)(n.N,{className:c("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),m((e=>!e)),null===s||void 0===s||s()},children:g}):null]})}},88616:(e,t,a)=>{a.d(t,{Q:()=>P});var r=a(59284),n=a(76938),o=a(98089),l=a(99991),s=a(80987),i=a(22983),d=a(28539),u=a(10508),c=a(44508),p=a(44294),h=a(17594),m=a(41775),g=a(69326),b=a(80420),y=a(27775),v=a(41826),f=a(21545),x=a(6354),C=a(76086),w=a(12888),j=a(29819),N=a(48372);const S=JSON.parse('{"noTabletsData":"No tablets data","Type":"Type","Tablet":"Tablet","State":"State","Node ID":"Node ID","Node FQDN":"Node FQDN","Generation":"Generation","Uptime":"Uptime","dialog.kill-header":"Restart tablet","dialog.kill-text":"The tablet will be restarted. Do you want to proceed?","controls.kill-not-allowed":"You don\'t have enough rights to restart tablet","controls.search-placeholder":"Tablet ID","controls.entities-count-label":"Tablets"}'),T=(0,N.g4)("ydb-tablets",{en:S});var F=a(60712);function I(e){const t=e.State===x.r.Stopped,a=(0,w.X)(),[r]=f.X.useKillTabletMutation(),o=e.TabletId;return o?(0,F.jsx)(i.B,{buttonView:"outlined",buttonTitle:T("dialog.kill-header"),dialogHeader:T("dialog.kill-header"),dialogText:T("dialog.kill-text"),onConfirmAction:()=>r({id:o}).unwrap(),buttonDisabled:t||!a,withPopover:!0,popoverContent:T(a?"dialog.kill-header":"controls.kill-not-allowed"),popoverPlacement:["right","auto"],popoverDisabled:!1,children:(0,F.jsx)(l.I,{data:n.A})}):null}function P({database:e,tablets:t,loading:a,error:n,scrollContainerRef:l}){const[{tabletsSearch:i},f]=(0,s.useQueryParams)({tabletsSearch:s.StringParam}),x=r.useMemo((()=>function({database:e}){return[{name:"Type",width:150,get header(){return T("Type")},render:({row:e})=>{const t=!1===e.Leader;return(0,F.jsxs)("span",{children:[e.Type," ",t?(0,F.jsx)(o.E,{color:"secondary",children:"follower"}):""]})}},{name:"TabletId",width:220,get header(){return T("Tablet")},render:({row:t})=>t.TabletId?(0,F.jsx)(b.$,{tabletId:t.TabletId,database:e,followerId:t.FollowerId||void 0}):C.Pd},{name:"State",get header(){return T("State")},render:({row:e})=>(0,F.jsx)(y.i,{state:e.State})},{name:"NodeId",get header(){return T("Node ID")},render:({row:e})=>{const t=void 0===e.NodeId?void 0:(0,j.vI)(e.NodeId);return(0,F.jsx)(p.E,{to:t,children:e.NodeId})},align:"right"},{name:"fqdn",get header(){return T("Node FQDN")},render:({row:e})=>e.fqdn?(0,F.jsx)(u.c,{name:e.fqdn,showStatus:!1,hasClipboardButton:!0}):(0,F.jsx)("span",{children:"\u2014"})},{name:"Generation",get header(){return T("Generation")},align:"right"},{name:"Uptime",get header(){return T("Uptime")},render:({row:e})=>(0,F.jsx)(v.H,{ChangeTime:e.ChangeTime}),sortAccessor:e=>-Number(e.ChangeTime),align:"right",width:120},{name:"Actions",sortable:!1,resizeable:!1,header:"",render:({row:e})=>(0,F.jsx)(I,{...e})}]}({database:e})),[e]),w=r.useMemo((()=>t.filter((e=>String(e.TabletId).includes(null!==i&&void 0!==i?i:"")))),[t,i]);return(0,F.jsxs)(g.L,{fullHeight:!0,children:[(0,F.jsxs)(g.L.Controls,{children:[(0,F.jsx)(m.v,{placeholder:T("controls.search-placeholder"),onChange:e=>{f({tabletsSearch:e||void 0},"replaceIn")},value:null!==i&&void 0!==i?i:"",width:238}),(0,F.jsx)(d.T,{label:T("controls.entities-count-label"),loading:a,total:t.length,current:w.length})]}),n?(0,F.jsx)(c.o,{error:n}):null,(0,F.jsx)(g.L.Table,{scrollContainerRef:l,scrollDependencies:[i],loading:a,children:(0,F.jsx)(h.l,{columns:x,data:w,settings:C.N3,emptyDataMessage:T("noTabletsData")})})]})}},95963:(e,t,a)=>{a.d(t,{v:()=>r.v});var r=a(41775)}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4349.9c8d20fd.chunk.js b/ydb/core/viewer/monitoring/static/js/4349.9c8d20fd.chunk.js deleted file mode 100644 index 2085038e42bc..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4349.9c8d20fd.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4349],{24349:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-tn",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u062c\u0627\u0646\u0641\u064a_\u0641\u064a\u0641\u0631\u064a_\u0645\u0627\u0631\u0633_\u0623\u0641\u0631\u064a\u0644_\u0645\u0627\u064a_\u062c\u0648\u0627\u0646_\u062c\u0648\u064a\u0644\u064a\u0629_\u0623\u0648\u062a_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),weekStart:1,weekdaysShort:"\u0623\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0623\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u062c\u0627\u0646\u0641\u064a_\u0641\u064a\u0641\u0631\u064a_\u0645\u0627\u0631\u0633_\u0623\u0641\u0631\u064a\u0644_\u0645\u0627\u064a_\u062c\u0648\u0627\u0646_\u062c\u0648\u064a\u0644\u064a\u0629_\u0623\u0648\u062a_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/43702.745d5072.chunk.js b/ydb/core/viewer/monitoring/static/js/43702.745d5072.chunk.js new file mode 100644 index 000000000000..d18074747aae --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/43702.745d5072.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 43702.745d5072.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[43702],{43702:(e,n,o)=>{o.r(n),o.d(n,{conf:()=>t,language:()=>r});var t={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["var","end_var"],["var_input","end_var"],["var_output","end_var"],["var_in_out","end_var"],["var_temp","end_var"],["var_global","end_var"],["var_access","end_var"],["var_external","end_var"],["type","end_type"],["struct","end_struct"],["program","end_program"],["function","end_function"],["function_block","end_function_block"],["action","end_action"],["step","end_step"],["initial_step","end_step"],["transaction","end_transaction"],["configuration","end_configuration"],["tcp","end_tcp"],["recource","end_recource"],["channel","end_channel"],["library","end_library"],["folder","end_folder"],["binaries","end_binaries"],["includes","end_includes"],["sources","end_sources"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"/*",close:"*/"},{open:"'",close:"'",notIn:["string_sq"]},{open:'"',close:'"',notIn:["string_dq"]},{open:"var_input",close:"end_var"},{open:"var_output",close:"end_var"},{open:"var_in_out",close:"end_var"},{open:"var_temp",close:"end_var"},{open:"var_global",close:"end_var"},{open:"var_access",close:"end_var"},{open:"var_external",close:"end_var"},{open:"type",close:"end_type"},{open:"struct",close:"end_struct"},{open:"program",close:"end_program"},{open:"function",close:"end_function"},{open:"function_block",close:"end_function_block"},{open:"action",close:"end_action"},{open:"step",close:"end_step"},{open:"initial_step",close:"end_step"},{open:"transaction",close:"end_transaction"},{open:"configuration",close:"end_configuration"},{open:"tcp",close:"end_tcp"},{open:"recource",close:"end_recource"},{open:"channel",close:"end_channel"},{open:"library",close:"end_library"},{open:"folder",close:"end_folder"},{open:"binaries",close:"end_binaries"},{open:"includes",close:"end_includes"},{open:"sources",close:"end_sources"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"var",close:"end_var"},{open:"var_input",close:"end_var"},{open:"var_output",close:"end_var"},{open:"var_in_out",close:"end_var"},{open:"var_temp",close:"end_var"},{open:"var_global",close:"end_var"},{open:"var_access",close:"end_var"},{open:"var_external",close:"end_var"},{open:"type",close:"end_type"},{open:"struct",close:"end_struct"},{open:"program",close:"end_program"},{open:"function",close:"end_function"},{open:"function_block",close:"end_function_block"},{open:"action",close:"end_action"},{open:"step",close:"end_step"},{open:"initial_step",close:"end_step"},{open:"transaction",close:"end_transaction"},{open:"configuration",close:"end_configuration"},{open:"tcp",close:"end_tcp"},{open:"recource",close:"end_recource"},{open:"channel",close:"end_channel"},{open:"library",close:"end_library"},{open:"folder",close:"end_folder"},{open:"binaries",close:"end_binaries"},{open:"includes",close:"end_includes"},{open:"sources",close:"end_sources"}],folding:{markers:{start:new RegExp("^\\s*#pragma\\s+region\\b"),end:new RegExp("^\\s*#pragma\\s+endregion\\b")}}},r={defaultToken:"",tokenPostfix:".st",ignoreCase:!0,brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:["if","end_if","elsif","else","case","of","to","__try","__catch","__finally","do","with","by","while","repeat","end_while","end_repeat","end_case","for","end_for","task","retain","non_retain","constant","with","at","exit","return","interval","priority","address","port","on_channel","then","iec","file","uses","version","packagetype","displayname","copyright","summary","vendor","common_source","from","extends","implements"],constant:["false","true","null"],defineKeywords:["var","var_input","var_output","var_in_out","var_temp","var_global","var_access","var_external","end_var","type","end_type","struct","end_struct","program","end_program","function","end_function","function_block","end_function_block","interface","end_interface","method","end_method","property","end_property","namespace","end_namespace","configuration","end_configuration","tcp","end_tcp","resource","end_resource","channel","end_channel","library","end_library","folder","end_folder","binaries","end_binaries","includes","end_includes","sources","end_sources","action","end_action","step","initial_step","end_step","transaction","end_transaction"],typeKeywords:["int","sint","dint","lint","usint","uint","udint","ulint","real","lreal","time","date","time_of_day","date_and_time","string","bool","byte","word","dword","array","pointer","lword"],operators:["=",">","<",":",":=","<=",">=","<>","&","+","-","*","**","MOD","^","or","and","not","xor","abs","acos","asin","atan","cos","exp","expt","ln","log","sin","sqrt","tan","sel","max","min","limit","mux","shl","shr","rol","ror","indexof","sizeof","adr","adrinst","bitadr","is_valid","ref","ref_to"],builtinVariables:[],builtinFunctions:["sr","rs","tp","ton","tof","eq","ge","le","lt","ne","round","trunc","ctd","\u0441tu","ctud","r_trig","f_trig","move","concat","delete","find","insert","left","len","replace","right","rtc"],symbols:/[=>{function n(e){!function(e){function n(e){return function(){return e}}var a=/\b(?:align|allowzero|and|anyframe|anytype|asm|async|await|break|cancel|catch|comptime|const|continue|defer|else|enum|errdefer|error|export|extern|fn|for|if|inline|linksection|nakedcc|noalias|nosuspend|null|or|orelse|packed|promise|pub|resume|return|stdcallcc|struct|suspend|switch|test|threadlocal|try|undefined|union|unreachable|usingnamespace|var|volatile|while)\b/,r="\\b(?!"+a.source+")(?!\\d)\\w+\\b",s=/align\s*\((?:[^()]|\([^()]*\))*\)/.source,o="(?!\\s)(?:!?\\s*(?:"+/(?:\?|\bpromise->|(?:\[[^[\]]*\]|\*(?!\*)|\*\*)(?:\s*|\s*const\b|\s*volatile\b|\s*allowzero\b)*)/.source.replace(//g,n(s))+"\\s*)*"+/(?:\bpromise\b|(?:\berror\.)?(?:\.)*(?!\s+))/.source.replace(//g,n(r))+")+";e.languages.zig={comment:[{pattern:/\/\/[/!].*/,alias:"doc-comment"},/\/{2}.*/],string:[{pattern:/(^|[^\\@])c?"(?:[^"\\\r\n]|\\.)*"/,lookbehind:!0,greedy:!0},{pattern:/([\r\n])([ \t]+c?\\{2}).*(?:(?:\r\n?|\n)\2.*)*/,lookbehind:!0,greedy:!0}],char:{pattern:/(^|[^\\])'(?:[^'\\\r\n]|[\uD800-\uDFFF]{2}|\\(?:.|x[a-fA-F\d]{2}|u\{[a-fA-F\d]{1,6}\}))'/,lookbehind:!0,greedy:!0},builtin:/\B@(?!\d)\w+(?=\s*\()/,label:{pattern:/(\b(?:break|continue)\s*:\s*)\w+\b|\b(?!\d)\w+\b(?=\s*:\s*(?:\{|while\b))/,lookbehind:!0},"class-name":[/\b(?!\d)\w+(?=\s*=\s*(?:(?:extern|packed)\s+)?(?:enum|struct|union)\s*[({])/,{pattern:RegExp(/(:\s*)(?=\s*(?:\s*)?[=;,)])|(?=\s*(?:\s*)?\{)/.source.replace(//g,n(o)).replace(//g,n(s))),lookbehind:!0,inside:null},{pattern:RegExp(/(\)\s*)(?=\s*(?:\s*)?;)/.source.replace(//g,n(o)).replace(//g,n(s))),lookbehind:!0,inside:null}],"builtin-type":{pattern:/\b(?:anyerror|bool|c_u?(?:int|long|longlong|short)|c_longdouble|c_void|comptime_(?:float|int)|f(?:16|32|64|128)|[iu](?:8|16|32|64|128|size)|noreturn|type|void)\b/,alias:"keyword"},keyword:a,function:/\b(?!\d)\w+(?=\s*\()/,number:/\b(?:0b[01]+|0o[0-7]+|0x[a-fA-F\d]+(?:\.[a-fA-F\d]*)?(?:[pP][+-]?[a-fA-F\d]+)?|\d+(?:\.\d*)?(?:[eE][+-]?\d+)?)\b/,boolean:/\b(?:false|true)\b/,operator:/\.[*?]|\.{2,3}|[-=]>|\*\*|\+\+|\|\||(?:<<|>>|[-+*]%|[-+*/%^&|<>!=])=?|[?~]/,punctuation:/[.:,;(){}[\]]/},e.languages.zig["class-name"].forEach((function(n){null===n.inside&&(n.inside=e.languages.zig)}))}(e)}e.exports=n,n.displayName="zig",n.aliases=[]},43979:(e,n,a)=>{a.d(n,{default:()=>s});var r=a(1888);const s=a.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4401.f46d19f6.chunk.js b/ydb/core/viewer/monitoring/static/js/4401.f46d19f6.chunk.js deleted file mode 100644 index 7ee3707cf5d3..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4401.f46d19f6.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4401],{6782:function(u,r,n){u.exports=function(u){"use strict";function r(u){return u&&"object"==typeof u&&"default"in u?u:{default:u}}var n=r(u),e={s:["nokkrar sek\xfandur","nokkrar sek\xfandur","nokkrum sek\xfandum"],m:["m\xedn\xfata","m\xedn\xfatu","m\xedn\xfatu"],mm:["m\xedn\xfatur","m\xedn\xfatur","m\xedn\xfatum"],h:["klukkustund","klukkustund","klukkustund"],hh:["klukkustundir","klukkustundir","klukkustundum"],d:["dagur","dag","degi"],dd:["dagar","daga","d\xf6gum"],M:["m\xe1nu\xf0ur","m\xe1nu\xf0","m\xe1nu\xf0i"],MM:["m\xe1nu\xf0ir","m\xe1nu\xf0i","m\xe1nu\xf0um"],y:["\xe1r","\xe1r","\xe1ri"],yy:["\xe1r","\xe1r","\xe1rum"]};function t(u,r,n,t){var m=function(u,r,n,t){var m=t?0:n?1:2,a=2===u.length&&r%10==1?u[0]:u,d=e[a][m];return 1===u.length?d:"%d "+d}(n,u,t,r);return m.replace("%d",u)}var m={name:"is",weekdays:"sunnudagur_m\xe1nudagur_\xferi\xf0judagur_mi\xf0vikudagur_fimmtudagur_f\xf6studagur_laugardagur".split("_"),months:"jan\xfaar_febr\xfaar_mars_apr\xedl_ma\xed_j\xfan\xed_j\xfal\xed_\xe1g\xfast_september_okt\xf3ber_n\xf3vember_desember".split("_"),weekStart:1,weekdaysShort:"sun_m\xe1n_\xferi_mi\xf0_fim_f\xf6s_lau".split("_"),monthsShort:"jan_feb_mar_apr_ma\xed_j\xfan_j\xfal_\xe1g\xfa_sep_okt_n\xf3v_des".split("_"),weekdaysMin:"Su_M\xe1_\xder_Mi_Fi_F\xf6_La".split("_"),ordinal:function(u){return u},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY [kl.] H:mm",LLLL:"dddd, D. MMMM YYYY [kl.] H:mm"},relativeTime:{future:"eftir %s",past:"fyrir %s s\xed\xf0an",s:t,m:t,mm:t,h:t,hh:t,d:t,dd:t,M:t,MM:t,y:t,yy:t}};return n.default.locale(m,null,!0),m}(n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/44096.4faf307e.chunk.js b/ydb/core/viewer/monitoring/static/js/44096.4faf307e.chunk.js new file mode 100644 index 000000000000..7c4ccb672872 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/44096.4faf307e.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[44096],{44096:function(t,_,e){t.exports=function(t){"use strict";function _(t){return t&&"object"==typeof t&&"default"in t?t:{default:t}}var e=_(t),a={name:"mt",weekdays:"Il-\u0126add_It-Tnejn_It-Tlieta_L-Erbg\u0127a_Il-\u0126amis_Il-\u0120img\u0127a_Is-Sibt".split("_"),months:"Jannar_Frar_Marzu_April_Mejju_\u0120unju_Lulju_Awwissu_Settembru_Ottubru_Novembru_Di\u010bembru".split("_"),weekStart:1,weekdaysShort:"\u0126ad_Tne_Tli_Erb_\u0126am_\u0120im_Sib".split("_"),monthsShort:"Jan_Fra_Mar_Apr_Mej_\u0120un_Lul_Aww_Set_Ott_Nov_Di\u010b".split("_"),weekdaysMin:"\u0126a_Tn_Tl_Er_\u0126a_\u0120i_Si".split("_"),ordinal:function(t){return t},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"f\u2019 %s",past:"%s ilu",s:"ftit sekondi",m:"minuta",mm:"%d minuti",h:"sieg\u0127a",hh:"%d sieg\u0127at",d:"\u0121urnata",dd:"%d \u0121ranet",M:"xahar",MM:"%d xhur",y:"sena",yy:"%d sni"}};return e.default.locale(a,null,!0),a}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/44391.7bf4eade.chunk.js b/ydb/core/viewer/monitoring/static/js/44391.7bf4eade.chunk.js new file mode 100644 index 000000000000..c902dee106d9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/44391.7bf4eade.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[44391],{44391:(e,a,n)=>{n.d(a,{default:()=>r});var t=n(50402);const r=n.n(t)()},50402:e=>{function a(e){e.languages["avro-idl"]={comment:{pattern:/\/\/.*|\/\*[\s\S]*?\*\//,greedy:!0},string:{pattern:/(^|[^\\])"(?:[^\r\n"\\]|\\.)*"/,lookbehind:!0,greedy:!0},annotation:{pattern:/@(?:[$\w.-]|`[^\r\n`]+`)+/,greedy:!0,alias:"function"},"function-identifier":{pattern:/`[^\r\n`]+`(?=\s*\()/,greedy:!0,alias:"function"},identifier:{pattern:/`[^\r\n`]+`/,greedy:!0},"class-name":{pattern:/(\b(?:enum|error|protocol|record|throws)\b\s+)[$\w]+/,lookbehind:!0,greedy:!0},keyword:/\b(?:array|boolean|bytes|date|decimal|double|enum|error|false|fixed|float|idl|import|int|local_timestamp_ms|long|map|null|oneway|protocol|record|schema|string|throws|time_ms|timestamp_ms|true|union|uuid|void)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:[{pattern:/(^|[^\w.])-?(?:(?:\d+(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?|0x(?:[a-f0-9]+(?:\.[a-f0-9]*)?|\.[a-f0-9]+)(?:p[+-]?\d+)?)[dfl]?(?![\w.])/i,lookbehind:!0},/-?\b(?:Infinity|NaN)\b/],operator:/=/,punctuation:/[()\[\]{}<>.:,;-]/},e.languages.avdl=e.languages["avro-idl"]}e.exports=a,a.displayName="avroIdl",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/44601.53b5fa99.chunk.js b/ydb/core/viewer/monitoring/static/js/44601.53b5fa99.chunk.js new file mode 100644 index 000000000000..cd51e782ca6b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/44601.53b5fa99.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[44601],{44601:function(a,j,r){a.exports=function(a){"use strict";function j(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var r=j(a),_={name:"tlh",weekdays:"lojmItjaj_DaSjaj_povjaj_ghItlhjaj_loghjaj_buqjaj_ghInjaj".split("_"),months:"tera\u2019 jar wa\u2019_tera\u2019 jar cha\u2019_tera\u2019 jar wej_tera\u2019 jar loS_tera\u2019 jar vagh_tera\u2019 jar jav_tera\u2019 jar Soch_tera\u2019 jar chorgh_tera\u2019 jar Hut_tera\u2019 jar wa\u2019maH_tera\u2019 jar wa\u2019maH wa\u2019_tera\u2019 jar wa\u2019maH cha\u2019".split("_"),weekStart:1,weekdaysShort:"lojmItjaj_DaSjaj_povjaj_ghItlhjaj_loghjaj_buqjaj_ghInjaj".split("_"),monthsShort:"jar wa\u2019_jar cha\u2019_jar wej_jar loS_jar vagh_jar jav_jar Soch_jar chorgh_jar Hut_jar wa\u2019maH_jar wa\u2019maH wa\u2019_jar wa\u2019maH cha\u2019".split("_"),weekdaysMin:"lojmItjaj_DaSjaj_povjaj_ghItlhjaj_loghjaj_buqjaj_ghInjaj".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"}};return r.default.locale(_,null,!0),_}(r(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/44846.352e01be.chunk.js b/ydb/core/viewer/monitoring/static/js/44846.352e01be.chunk.js new file mode 100644 index 000000000000..0bece7e21070 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/44846.352e01be.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 44846.352e01be.chunk.js.LICENSE.txt */ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[44846],{2120:(e,t,n)=>{var a=function(e){var t=/(?:^|\s)lang(?:uage)?-([\w-]+)(?=\s|$)/i,n=0,a={},r={manual:e.Prism&&e.Prism.manual,disableWorkerMessageHandler:e.Prism&&e.Prism.disableWorkerMessageHandler,util:{encode:function e(t){return t instanceof s?new s(t.type,e(t.content),t.alias):Array.isArray(t)?t.map(e):t.replace(/&/g,"&").replace(/=c.reach);w+=x.value.length,x=x.next){var A=x.value;if(t.length>e.length)return;if(!(A instanceof s)){var $,S=1;if(b){if(!($=i(k,w,e,v))||$.index>=e.length)break;var E=$.index,_=$.index+$[0].length,j=w;for(j+=x.value.length;E>=j;)j+=(x=x.next).value.length;if(w=j-=x.value.length,x.value instanceof s)continue;for(var C=x;C!==t.tail&&(j<_||"string"===typeof C.value);C=C.next)S++,j+=C.value.length;S--,A=e.slice(w,j),$.index-=w}else if(!($=i(k,0,A,v)))continue;E=$.index;var L=$[0],z=A.slice(0,E),O=A.slice(E+L.length),P=w+A.length;c&&P>c.reach&&(c.reach=P);var T=x.prev;if(z&&(T=u(t,T,z),w+=z.length),g(t,T,S),x=u(t,T,new s(d,m?r.tokenize(L,m):L,y,L)),O&&u(t,x,O),S>1){var M={cause:d+","+h,reach:P};o(e,t,n,x.prev,w,M),c&&M.reach>c.reach&&(c.reach=M.reach)}}}}}}function l(){var e={value:null,prev:null,next:null},t={value:null,prev:e,next:null};e.next=t,this.head=e,this.tail=t,this.length=0}function u(e,t,n){var a=t.next,r={value:n,prev:t,next:a};return t.next=r,a.prev=r,e.length++,r}function g(e,t,n){for(var a=t.next,r=0;r"+s.content+""},!e.document)return e.addEventListener?(r.disableWorkerMessageHandler||e.addEventListener("message",(function(t){var n=JSON.parse(t.data),a=n.language,s=n.code,i=n.immediateClose;e.postMessage(r.highlight(s,r.languages[a],a)),i&&e.close()}),!1),r):r;var c=r.util.currentScript();function d(){r.manual||r.highlightAll()}if(c&&(r.filename=c.src,c.hasAttribute("data-manual")&&(r.manual=!0)),!r.manual){var p=document.readyState;"loading"===p||"interactive"===p&&c&&c.defer?document.addEventListener("DOMContentLoaded",d):window.requestAnimationFrame?window.requestAnimationFrame(d):window.setTimeout(d,16)}return r}("undefined"!==typeof window?window:"undefined"!==typeof WorkerGlobalScope&&self instanceof WorkerGlobalScope?self:{});e.exports&&(e.exports=a),"undefined"!==typeof n.g&&(n.g.Prism=a),a.languages.markup={comment:{pattern://,greedy:!0},prolog:{pattern:/<\?[\s\S]+?\?>/,greedy:!0},doctype:{pattern:/"'[\]]|"[^"]*"|'[^']*')+(?:\[(?:[^<"'\]]|"[^"]*"|'[^']*'|<(?!!--)|)*\]\s*)?>/i,greedy:!0,inside:{"internal-subset":{pattern:/(^[^\[]*\[)[\s\S]+(?=\]>$)/,lookbehind:!0,greedy:!0,inside:null},string:{pattern:/"[^"]*"|'[^']*'/,greedy:!0},punctuation:/^$|[[\]]/,"doctype-tag":/^DOCTYPE/i,name:/[^\s<>'"]+/}},cdata:{pattern://i,greedy:!0},tag:{pattern:/<\/?(?!\d)[^\s>\/=$<%]+(?:\s(?:\s*[^\s>\/=]+(?:\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))|(?=[\s/>])))+)?\s*\/?>/,greedy:!0,inside:{tag:{pattern:/^<\/?[^\s>\/]+/,inside:{punctuation:/^<\/?/,namespace:/^[^\s>\/:]+:/}},"special-attr":[],"attr-value":{pattern:/=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+)/,inside:{punctuation:[{pattern:/^=/,alias:"attr-equals"},{pattern:/^(\s*)["']|["']$/,lookbehind:!0}]}},punctuation:/\/?>/,"attr-name":{pattern:/[^\s>\/]+/,inside:{namespace:/^[^\s>\/:]+:/}}}},entity:[{pattern:/&[\da-z]{1,8};/i,alias:"named-entity"},/&#x?[\da-f]{1,8};/i]},a.languages.markup.tag.inside["attr-value"].inside.entity=a.languages.markup.entity,a.languages.markup.doctype.inside["internal-subset"].inside=a.languages.markup,a.hooks.add("wrap",(function(e){"entity"===e.type&&(e.attributes.title=e.content.replace(/&/,"&"))})),Object.defineProperty(a.languages.markup.tag,"addInlined",{value:function(e,t){var n={};n["language-"+t]={pattern:/(^$)/i,lookbehind:!0,inside:a.languages[t]},n.cdata=/^$/i;var r={"included-cdata":{pattern://i,inside:n}};r["language-"+t]={pattern:/[\s\S]+/,inside:a.languages[t]};var s={};s[e]={pattern:RegExp(/(<__[^>]*>)(?:))*\]\]>|(?!)/.source.replace(/__/g,(function(){return e})),"i"),lookbehind:!0,greedy:!0,inside:r},a.languages.insertBefore("markup","cdata",s)}}),Object.defineProperty(a.languages.markup.tag,"addAttribute",{value:function(e,t){a.languages.markup.tag.inside["special-attr"].push({pattern:RegExp(/(^|["'\s])/.source+"(?:"+e+")"+/\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))/.source,"i"),lookbehind:!0,inside:{"attr-name":/^[^\s=]+/,"attr-value":{pattern:/=[\s\S]+/,inside:{value:{pattern:/(^=\s*(["']|(?!["'])))\S[\s\S]*(?=\2$)/,lookbehind:!0,alias:[t,"language-"+t],inside:a.languages[t]},punctuation:[{pattern:/^=/,alias:"attr-equals"},/"|'/]}}}})}}),a.languages.html=a.languages.markup,a.languages.mathml=a.languages.markup,a.languages.svg=a.languages.markup,a.languages.xml=a.languages.extend("markup",{}),a.languages.ssml=a.languages.xml,a.languages.atom=a.languages.xml,a.languages.rss=a.languages.xml,function(e){var t=/(?:"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"|'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n])*')/;e.languages.css={comment:/\/\*[\s\S]*?\*\//,atrule:{pattern:RegExp("@[\\w-](?:"+/[^;{\s"']|\s+(?!\s)/.source+"|"+t.source+")*?"+/(?:;|(?=\s*\{))/.source),inside:{rule:/^@[\w-]+/,"selector-function-argument":{pattern:/(\bselector\s*\(\s*(?![\s)]))(?:[^()\s]|\s+(?![\s)])|\((?:[^()]|\([^()]*\))*\))+(?=\s*\))/,lookbehind:!0,alias:"selector"},keyword:{pattern:/(^|[^\w-])(?:and|not|only|or)(?![\w-])/,lookbehind:!0}}},url:{pattern:RegExp("\\burl\\((?:"+t.source+"|"+/(?:[^\\\r\n()"']|\\[\s\S])*/.source+")\\)","i"),greedy:!0,inside:{function:/^url/i,punctuation:/^\(|\)$/,string:{pattern:RegExp("^"+t.source+"$"),alias:"url"}}},selector:{pattern:RegExp("(^|[{}\\s])[^{}\\s](?:[^{};\"'\\s]|\\s+(?![\\s{])|"+t.source+")*(?=\\s*\\{)"),lookbehind:!0},string:{pattern:t,greedy:!0},property:{pattern:/(^|[^-\w\xA0-\uFFFF])(?!\s)[-_a-z\xA0-\uFFFF](?:(?!\s)[-\w\xA0-\uFFFF])*(?=\s*:)/i,lookbehind:!0},important:/!important\b/i,function:{pattern:/(^|[^-a-z0-9])[-a-z0-9]+(?=\()/i,lookbehind:!0},punctuation:/[(){};:,]/},e.languages.css.atrule.inside.rest=e.languages.css;var n=e.languages.markup;n&&(n.tag.addInlined("style","css"),n.tag.addAttribute("style","css"))}(a),a.languages.clike={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?(?:\*\/|$)/,lookbehind:!0,greedy:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0,greedy:!0}],string:{pattern:/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0},"class-name":{pattern:/(\b(?:class|extends|implements|instanceof|interface|new|trait)\s+|\bcatch\s+\()[\w.\\]+/i,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:break|catch|continue|do|else|finally|for|function|if|in|instanceof|new|null|return|throw|try|while)\b/,boolean:/\b(?:false|true)\b/,function:/\b\w+(?=\()/,number:/\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?/i,operator:/[<>]=?|[!=]=?=?|--?|\+\+?|&&?|\|\|?|[?*/~^%]/,punctuation:/[{}[\];(),.:]/},a.languages.javascript=a.languages.extend("clike",{"class-name":[a.languages.clike["class-name"],{pattern:/(^|[^$\w\xA0-\uFFFF])(?!\s)[_$A-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\.(?:constructor|prototype))/,lookbehind:!0}],keyword:[{pattern:/((?:^|\})\s*)catch\b/,lookbehind:!0},{pattern:/(^|[^.]|\.\.\.\s*)\b(?:as|assert(?=\s*\{)|async(?=\s*(?:function\b|\(|[$\w\xA0-\uFFFF]|$))|await|break|case|class|const|continue|debugger|default|delete|do|else|enum|export|extends|finally(?=\s*(?:\{|$))|for|from(?=\s*(?:['"]|$))|function|(?:get|set)(?=\s*(?:[#\[$\w\xA0-\uFFFF]|$))|if|implements|import|in|instanceof|interface|let|new|null|of|package|private|protected|public|return|static|super|switch|this|throw|try|typeof|undefined|var|void|while|with|yield)\b/,lookbehind:!0}],function:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*(?:\.\s*(?:apply|bind|call)\s*)?\()/,number:{pattern:RegExp(/(^|[^\w$])/.source+"(?:"+/NaN|Infinity/.source+"|"+/0[bB][01]+(?:_[01]+)*n?/.source+"|"+/0[oO][0-7]+(?:_[0-7]+)*n?/.source+"|"+/0[xX][\dA-Fa-f]+(?:_[\dA-Fa-f]+)*n?/.source+"|"+/\d+(?:_\d+)*n/.source+"|"+/(?:\d+(?:_\d+)*(?:\.(?:\d+(?:_\d+)*)?)?|\.\d+(?:_\d+)*)(?:[Ee][+-]?\d+(?:_\d+)*)?/.source+")"+/(?![\w$])/.source),lookbehind:!0},operator:/--|\+\+|\*\*=?|=>|&&=?|\|\|=?|[!=]==|<<=?|>>>?=?|[-+*/%&|^!=<>]=?|\.{3}|\?\?=?|\?\.?|[~:]/}),a.languages.javascript["class-name"][0].pattern=/(\b(?:class|extends|implements|instanceof|interface|new)\s+)[\w.\\]+/,a.languages.insertBefore("javascript","keyword",{regex:{pattern:RegExp(/((?:^|[^$\w\xA0-\uFFFF."'\])\s]|\b(?:return|yield))\s*)/.source+/\//.source+"(?:"+/(?:\[(?:[^\]\\\r\n]|\\.)*\]|\\.|[^/\\\[\r\n])+\/[dgimyus]{0,7}/.source+"|"+/(?:\[(?:[^[\]\\\r\n]|\\.|\[(?:[^[\]\\\r\n]|\\.|\[(?:[^[\]\\\r\n]|\\.)*\])*\])*\]|\\.|[^/\\\[\r\n])+\/[dgimyus]{0,7}v[dgimyus]{0,7}/.source+")"+/(?=(?:\s|\/\*(?:[^*]|\*(?!\/))*\*\/)*(?:$|[\r\n,.;:})\]]|\/\/))/.source),lookbehind:!0,greedy:!0,inside:{"regex-source":{pattern:/^(\/)[\s\S]+(?=\/[a-z]*$)/,lookbehind:!0,alias:"language-regex",inside:a.languages.regex},"regex-delimiter":/^\/|\/$/,"regex-flags":/^[a-z]+$/}},"function-variable":{pattern:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*[=:]\s*(?:async\s*)?(?:\bfunction\b|(?:\((?:[^()]|\([^()]*\))*\)|(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)\s*=>))/,alias:"function"},parameter:[{pattern:/(function(?:\s+(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)?\s*\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\))/,lookbehind:!0,inside:a.languages.javascript},{pattern:/(^|[^$\w\xA0-\uFFFF])(?!\s)[_$a-z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*=>)/i,lookbehind:!0,inside:a.languages.javascript},{pattern:/(\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\)\s*=>)/,lookbehind:!0,inside:a.languages.javascript},{pattern:/((?:\b|\s|^)(?!(?:as|async|await|break|case|catch|class|const|continue|debugger|default|delete|do|else|enum|export|extends|finally|for|from|function|get|if|implements|import|in|instanceof|interface|let|new|null|of|package|private|protected|public|return|set|static|super|switch|this|throw|try|typeof|undefined|var|void|while|with|yield)(?![$\w\xA0-\uFFFF]))(?:(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*\s*)\(\s*|\]\s*\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\)\s*\{)/,lookbehind:!0,inside:a.languages.javascript}],constant:/\b[A-Z](?:[A-Z_]|\dx?)*\b/}),a.languages.insertBefore("javascript","string",{hashbang:{pattern:/^#!.*/,greedy:!0,alias:"comment"},"template-string":{pattern:/`(?:\\[\s\S]|\$\{(?:[^{}]|\{(?:[^{}]|\{[^}]*\})*\})+\}|(?!\$\{)[^\\`])*`/,greedy:!0,inside:{"template-punctuation":{pattern:/^`|`$/,alias:"string"},interpolation:{pattern:/((?:^|[^\\])(?:\\{2})*)\$\{(?:[^{}]|\{(?:[^{}]|\{[^}]*\})*\})+\}/,lookbehind:!0,inside:{"interpolation-punctuation":{pattern:/^\$\{|\}$/,alias:"punctuation"},rest:a.languages.javascript}},string:/[\s\S]+/}},"string-property":{pattern:/((?:^|[,{])[ \t]*)(["'])(?:\\(?:\r\n|[\s\S])|(?!\2)[^\\\r\n])*\2(?=\s*:)/m,lookbehind:!0,greedy:!0,alias:"property"}}),a.languages.insertBefore("javascript","operator",{"literal-property":{pattern:/((?:^|[,{])[ \t]*)(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*:)/m,lookbehind:!0,alias:"property"}}),a.languages.markup&&(a.languages.markup.tag.addInlined("script","javascript"),a.languages.markup.tag.addAttribute(/on(?:abort|blur|change|click|composition(?:end|start|update)|dblclick|error|focus(?:in|out)?|key(?:down|up)|load|mouse(?:down|enter|leave|move|out|over|up)|reset|resize|scroll|select|slotchange|submit|unload|wheel)/.source,"javascript")),a.languages.js=a.languages.javascript,function(){if("undefined"!==typeof a&&"undefined"!==typeof document){Element.prototype.matches||(Element.prototype.matches=Element.prototype.msMatchesSelector||Element.prototype.webkitMatchesSelector);var e={js:"javascript",py:"python",rb:"ruby",ps1:"powershell",psm1:"powershell",sh:"bash",bat:"batch",h:"c",tex:"latex"},t="data-src-status",n="loading",r="loaded",s="pre[data-src]:not(["+t+'="'+r+'"]):not(['+t+'="'+n+'"])';a.hooks.add("before-highlightall",(function(e){e.selector+=", "+s})),a.hooks.add("before-sanity-check",(function(i){var o=i.element;if(o.matches(s)){i.code="",o.setAttribute(t,n);var l=o.appendChild(document.createElement("CODE"));l.textContent="Loading\u2026";var u=o.getAttribute("data-src"),g=i.language;if("none"===g){var c=(/\.(\w+)$/.exec(u)||[,"none"])[1];g=e[c]||c}a.util.setLanguage(l,g),a.util.setLanguage(o,g);var d=a.plugins.autoloader;d&&d.loadLanguages(g),function(e,t,n){var a=new XMLHttpRequest;a.open("GET",e,!0),a.onreadystatechange=function(){4==a.readyState&&(a.status<400&&a.responseText?t(a.responseText):a.status>=400?n("\u2716 Error "+a.status+" while fetching file: "+a.statusText):n("\u2716 Error: File does not exist or is empty"))},a.send(null)}(u,(function(e){o.setAttribute(t,r);var n=function(e){var t=/^\s*(\d+)\s*(?:(,)\s*(?:(\d+)\s*)?)?$/.exec(e||"");if(t){var n=Number(t[1]),a=t[2],r=t[3];return a?r?[n,Number(r)]:[n,void 0]:[n,n]}}(o.getAttribute("data-range"));if(n){var s=e.split(/\r\n?|\n/g),i=n[0],u=null==n[1]?s.length:n[1];i<0&&(i+=s.length),i=Math.max(0,Math.min(i-1,s.length)),u<0&&(u+=s.length),u=Math.max(0,Math.min(u,s.length)),e=s.slice(i,u).join("\n"),o.hasAttribute("data-start")||o.setAttribute("data-start",String(i+1))}l.textContent=e,a.highlightElement(l)}),(function(e){o.setAttribute(t,"failed"),l.textContent=e}))}})),a.plugins.fileHighlight={highlight:function(e){for(var t,n=(e||document).querySelectorAll(s),r=0;t=n[r++];)a.highlightElement(t)}};var i=!1;a.fileHighlight=function(){i||(console.warn("Prism.fileHighlight is deprecated. Use `Prism.plugins.fileHighlight.highlight` instead."),i=!0),a.plugins.fileHighlight.highlight.apply(this,arguments)}}}()},44846:(e,t,n)=>{"use strict";n.d(t,{default:()=>r});var a=n(2120);const r=n.n(a)().languages.core}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6820.73ff230e.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/44846.352e01be.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6820.73ff230e.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/44846.352e01be.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/44866.fde9a535.chunk.js b/ydb/core/viewer/monitoring/static/js/44866.fde9a535.chunk.js new file mode 100644 index 000000000000..6e659e547d31 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/44866.fde9a535.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[44866],{7569:e=>{function a(e){e.languages.hcl={comment:/(?:\/\/|#).*|\/\*[\s\S]*?(?:\*\/|$)/,heredoc:{pattern:/<<-?(\w+\b)[\s\S]*?^[ \t]*\1/m,greedy:!0,alias:"string"},keyword:[{pattern:/(?:data|resource)\s+(?:"(?:\\[\s\S]|[^\\"])*")(?=\s+"[\w-]+"\s+\{)/i,inside:{type:{pattern:/(resource|data|\s+)(?:"(?:\\[\s\S]|[^\\"])*")/i,lookbehind:!0,alias:"variable"}}},{pattern:/(?:backend|module|output|provider|provisioner|variable)\s+(?:[\w-]+|"(?:\\[\s\S]|[^\\"])*")\s+(?=\{)/i,inside:{type:{pattern:/(backend|module|output|provider|provisioner|variable)\s+(?:[\w-]+|"(?:\\[\s\S]|[^\\"])*")\s+/i,lookbehind:!0,alias:"variable"}}},/[\w-]+(?=\s+\{)/],property:[/[-\w\.]+(?=\s*=(?!=))/,/"(?:\\[\s\S]|[^\\"])+"(?=\s*[:=])/],string:{pattern:/"(?:[^\\$"]|\\[\s\S]|\$(?:(?=")|\$+(?!\$)|[^"${])|\$\{(?:[^{}"]|"(?:[^\\"]|\\[\s\S])*")*\})*"/,greedy:!0,inside:{interpolation:{pattern:/(^|[^$])\$\{(?:[^{}"]|"(?:[^\\"]|\\[\s\S])*")*\}/,lookbehind:!0,inside:{type:{pattern:/(\b(?:count|data|local|module|path|self|terraform|var)\b\.)[\w\*]+/i,lookbehind:!0,alias:"variable"},keyword:/\b(?:count|data|local|module|path|self|terraform|var)\b/i,function:/\w+(?=\()/,string:{pattern:/"(?:\\[\s\S]|[^\\"])*"/,greedy:!0},number:/\b0x[\da-f]+\b|\b\d+(?:\.\d*)?(?:e[+-]?\d+)?/i,punctuation:/[!\$#%&'()*+,.\/;<=>@\[\\\]^`{|}~?:]/}}}},number:/\b0x[\da-f]+\b|\b\d+(?:\.\d*)?(?:e[+-]?\d+)?/i,boolean:/\b(?:false|true)\b/i,punctuation:/[=\[\]{}]/}}e.exports=a,a.displayName="hcl",a.aliases=[]},44866:(e,a,t)=>{t.d(a,{default:()=>r});var i=t(7569);const r=t.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4534.b98f1389.chunk.js b/ydb/core/viewer/monitoring/static/js/4534.b98f1389.chunk.js deleted file mode 100644 index 00c9e23dc11c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4534.b98f1389.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4534.b98f1389.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4534],{24534:(e,i,t)=>{t.r(i),t.d(i,{conf:()=>n,language:()=>s});var n={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},s={defaultToken:"",tokenPostfix:".cypher",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ALL","AND","AS","ASC","ASCENDING","BY","CALL","CASE","CONTAINS","CREATE","DELETE","DESC","DESCENDING","DETACH","DISTINCT","ELSE","END","ENDS","EXISTS","IN","IS","LIMIT","MANDATORY","MATCH","MERGE","NOT","ON","ON","OPTIONAL","OR","ORDER","REMOVE","RETURN","SET","SKIP","STARTS","THEN","UNION","UNWIND","WHEN","WHERE","WITH","XOR","YIELD"],builtinLiterals:["true","TRUE","false","FALSE","null","NULL"],builtinFunctions:["abs","acos","asin","atan","atan2","avg","ceil","coalesce","collect","cos","cot","count","degrees","e","endNode","exists","exp","floor","head","id","keys","labels","last","left","length","log","log10","lTrim","max","min","nodes","percentileCont","percentileDisc","pi","properties","radians","rand","range","relationships","replace","reverse","right","round","rTrim","sign","sin","size","split","sqrt","startNode","stDev","stDevP","substring","sum","tail","tan","timestamp","toBoolean","toFloat","toInteger","toLower","toString","toUpper","trim","type"],operators:["+","-","*","/","%","^","=","<>","<",">","<=",">=","->","<-","--\x3e","<--"],escapes:/\\(?:[tbnrf\\"'`]|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,digits:/\d+/,octaldigits:/[0-7]+/,hexdigits:/[0-9a-fA-F]+/,tokenizer:{root:[[/[{}[\]()]/,"@brackets"],{include:"common"}],common:[{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},[/:[a-zA-Z_][\w]*/,"type.identifier"],[/[a-zA-Z_][\w]*(?=\()/,{cases:{"@builtinFunctions":"predefined.function"}}],[/[a-zA-Z_$][\w$]*/,{cases:{"@keywords":"keyword","@builtinLiterals":"predefined.literal","@default":"identifier"}}],[/`/,"identifier.escape","@identifierBacktick"],[/[;,.:|]/,"delimiter"],[/[<>=%+\-*/^]+/,{cases:{"@operators":"delimiter","@default":""}}]],numbers:[[/-?(@digits)[eE](-?(@digits))?/,"number.float"],[/-?(@digits)?\.(@digits)([eE]-?(@digits))?/,"number.float"],[/-?0x(@hexdigits)/,"number.hex"],[/-?0(@octaldigits)/,"number.octal"],[/-?(@digits)/,"number"]],strings:[[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/"/,"string","@stringDouble"],[/'/,"string","@stringSingle"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/\/\/.*/,"comment"],[/[^/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[/*]/,"comment"]],stringDouble:[[/[^\\"]+/,"string"],[/@escapes/,"string"],[/\\./,"string.invalid"],[/"/,"string","@pop"]],stringSingle:[[/[^\\']+/,"string"],[/@escapes/,"string"],[/\\./,"string.invalid"],[/'/,"string","@pop"]],identifierBacktick:[[/[^\\`]+/,"identifier.escape"],[/@escapes/,"identifier.escape"],[/\\./,"identifier.escape.invalid"],[/`/,"identifier.escape","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4542.18433910.chunk.js b/ydb/core/viewer/monitoring/static/js/4542.18433910.chunk.js deleted file mode 100644 index 0c4b9ceb6209..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4542.18433910.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4542.18433910.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4542],{14542:(e,o,t)=>{t.r(o),t.d(o,{conf:()=>n,language:()=>s});var n={comments:{lineComment:"#"},brackets:[["[","]"],["<",">"],["(",")"]],autoClosingPairs:[{open:"[",close:"]"},{open:"<",close:">"},{open:"(",close:")"}],surroundingPairs:[{open:"[",close:"]"},{open:"<",close:">"},{open:"(",close:")"}]},s={defaultToken:"",tokenPostfix:".pla",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"<",close:">",token:"delimiter.angle"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:[".i",".o",".mv",".ilb",".ob",".label",".type",".phase",".pair",".symbolic",".symbolic-output",".kiss",".p",".e",".end"],comment:/#.*$/,identifier:/[a-zA-Z]+[a-zA-Z0-9_\-]*/,plaContent:/[01\-~\|]+/,tokenizer:{root:[{include:"@whitespace"},[/@comment/,"comment"],[/\.([a-zA-Z_\-]+)/,{cases:{"@eos":{token:"keyword.$1"},"@keywords":{cases:{".type":{token:"keyword.$1",next:"@type"},"@default":{token:"keyword.$1",next:"@keywordArg"}}},"@default":{token:"keyword.$1"}}}],[/@identifier/,"identifier"],[/@plaContent/,"string"]],whitespace:[[/[ \t\r\n]+/,""]],type:[{include:"@whitespace"},[/\w+/,{token:"type",next:"@pop"}]],keywordArg:[[/[ \t\r\n]+/,{cases:{"@eos":{token:"",next:"@pop"},"@default":""}}],[/@comment/,"comment","@pop"],[/[<>()\[\]]/,{cases:{"@eos":{token:"@brackets",next:"@pop"},"@default":"@brackets"}}],[/\-?\d+/,{cases:{"@eos":{token:"number",next:"@pop"},"@default":"number"}}],[/@identifier/,{cases:{"@eos":{token:"identifier",next:"@pop"},"@default":"identifier"}}],[/[;=]/,{cases:{"@eos":{token:"delimiter",next:"@pop"},"@default":"delimiter"}}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/45517.dd0696d8.chunk.js b/ydb/core/viewer/monitoring/static/js/45517.dd0696d8.chunk.js new file mode 100644 index 000000000000..b733d4a0a363 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/45517.dd0696d8.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[45517],{1726:e=>{function t(e){e.languages.d=e.languages.extend("clike",{comment:[{pattern:/^\s*#!.+/,greedy:!0},{pattern:RegExp(/(^|[^\\])/.source+"(?:"+[/\/\+(?:\/\+(?:[^+]|\+(?!\/))*\+\/|(?!\/\+)[\s\S])*?\+\//.source,/\/\/.*/.source,/\/\*[\s\S]*?\*\//.source].join("|")+")"),lookbehind:!0,greedy:!0}],string:[{pattern:RegExp([/\b[rx]"(?:\\[\s\S]|[^\\"])*"[cwd]?/.source,/\bq"(?:\[[\s\S]*?\]|\([\s\S]*?\)|<[\s\S]*?>|\{[\s\S]*?\})"/.source,/\bq"((?!\d)\w+)$[\s\S]*?^\1"/.source,/\bq"(.)[\s\S]*?\2"/.source,/(["`])(?:\\[\s\S]|(?!\3)[^\\])*\3[cwd]?/.source].join("|"),"m"),greedy:!0},{pattern:/\bq\{(?:\{[^{}]*\}|[^{}])*\}/,greedy:!0,alias:"token-string"}],keyword:/\$|\b(?:__(?:(?:DATE|EOF|FILE|FUNCTION|LINE|MODULE|PRETTY_FUNCTION|TIMESTAMP|TIME|VENDOR|VERSION)__|gshared|parameters|traits|vector)|abstract|alias|align|asm|assert|auto|body|bool|break|byte|case|cast|catch|cdouble|cent|cfloat|char|class|const|continue|creal|dchar|debug|default|delegate|delete|deprecated|do|double|dstring|else|enum|export|extern|false|final|finally|float|for|foreach|foreach_reverse|function|goto|idouble|if|ifloat|immutable|import|inout|int|interface|invariant|ireal|lazy|long|macro|mixin|module|new|nothrow|null|out|override|package|pragma|private|protected|ptrdiff_t|public|pure|real|ref|return|scope|shared|short|size_t|static|string|struct|super|switch|synchronized|template|this|throw|true|try|typedef|typeid|typeof|ubyte|ucent|uint|ulong|union|unittest|ushort|version|void|volatile|wchar|while|with|wstring)\b/,number:[/\b0x\.?[a-f\d_]+(?:(?!\.\.)\.[a-f\d_]*)?(?:p[+-]?[a-f\d_]+)?[ulfi]{0,4}/i,{pattern:/((?:\.\.)?)(?:\b0b\.?|\b|\.)\d[\d_]*(?:(?!\.\.)\.[\d_]*)?(?:e[+-]?\d[\d_]*)?[ulfi]{0,4}/i,lookbehind:!0}],operator:/\|[|=]?|&[&=]?|\+[+=]?|-[-=]?|\.?\.\.|=[>=]?|!(?:i[ns]\b|<>?=?|>=?|=)?|\bi[ns]\b|(?:<[<>]?|>>?>?|\^\^|[*\/%^~])=?/}),e.languages.insertBefore("d","string",{char:/'(?:\\(?:\W|\w+)|[^\\])'/}),e.languages.insertBefore("d","keyword",{property:/\B@\w*/}),e.languages.insertBefore("d","function",{register:{pattern:/\b(?:[ABCD][LHX]|E?(?:BP|DI|SI|SP)|[BS]PL|[ECSDGF]S|CR[0234]|[DS]IL|DR[012367]|E[ABCD]X|X?MM[0-7]|R(?:1[0-5]|[89])[BWD]?|R[ABCD]X|R[BS]P|R[DS]I|TR[3-7]|XMM(?:1[0-5]|[89])|YMM(?:1[0-5]|\d))\b|\bST(?:\([0-7]\)|\b)/,alias:"variable"}})}e.exports=t,t.displayName="d",t.aliases=[]},45517:(e,t,r)=>{r.d(t,{default:()=>s});var a=r(1726);const s=r.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4554.8b82bb25.chunk.js b/ydb/core/viewer/monitoring/static/js/4554.8b82bb25.chunk.js new file mode 100644 index 000000000000..744ee0cb64df --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/4554.8b82bb25.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4554],{4554:(e,r,t)=>{t.d(r,{default:()=>o});var a=t(77831);const o=t.n(a)()},77831:e=>{function r(e){!function(e){e.languages.scheme={comment:/;.*|#;\s*(?:\((?:[^()]|\([^()]*\))*\)|\[(?:[^\[\]]|\[[^\[\]]*\])*\])|#\|(?:[^#|]|#(?!\|)|\|(?!#)|#\|(?:[^#|]|#(?!\|)|\|(?!#))*\|#)*\|#/,string:{pattern:/"(?:[^"\\]|\\.)*"/,greedy:!0},symbol:{pattern:/'[^()\[\]#'\s]+/,greedy:!0},char:{pattern:/#\\(?:[ux][a-fA-F\d]+\b|[-a-zA-Z]+\b|[\uD800-\uDBFF][\uDC00-\uDFFF]|\S)/,greedy:!0},"lambda-parameter":[{pattern:/((?:^|[^'`#])[(\[]lambda\s+)(?:[^|()\[\]'\s]+|\|(?:[^\\|]|\\.)*\|)/,lookbehind:!0},{pattern:/((?:^|[^'`#])[(\[]lambda\s+[(\[])[^()\[\]']+/,lookbehind:!0}],keyword:{pattern:/((?:^|[^'`#])[(\[])(?:begin|case(?:-lambda)?|cond(?:-expand)?|define(?:-library|-macro|-record-type|-syntax|-values)?|defmacro|delay(?:-force)?|do|else|except|export|guard|if|import|include(?:-ci|-library-declarations)?|lambda|let(?:rec)?(?:-syntax|-values|\*)?|let\*-values|only|parameterize|prefix|(?:quasi-?)?quote|rename|set!|syntax-(?:case|rules)|unless|unquote(?:-splicing)?|when)(?=[()\[\]\s]|$)/,lookbehind:!0},builtin:{pattern:/((?:^|[^'`#])[(\[])(?:abs|and|append|apply|assoc|ass[qv]|binary-port\?|boolean=?\?|bytevector(?:-append|-copy|-copy!|-length|-u8-ref|-u8-set!|\?)?|caar|cadr|call-with-(?:current-continuation|port|values)|call\/cc|car|cdar|cddr|cdr|ceiling|char(?:->integer|-ready\?|\?|<\?|<=\?|=\?|>\?|>=\?)|close-(?:input-port|output-port|port)|complex\?|cons|current-(?:error|input|output)-port|denominator|dynamic-wind|eof-object\??|eq\?|equal\?|eqv\?|error|error-object(?:-irritants|-message|\?)|eval|even\?|exact(?:-integer-sqrt|-integer\?|\?)?|expt|features|file-error\?|floor(?:-quotient|-remainder|\/)?|flush-output-port|for-each|gcd|get-output-(?:bytevector|string)|inexact\??|input-port(?:-open\?|\?)|integer(?:->char|\?)|lcm|length|list(?:->string|->vector|-copy|-ref|-set!|-tail|\?)?|make-(?:bytevector|list|parameter|string|vector)|map|max|member|memq|memv|min|modulo|negative\?|newline|not|null\?|number(?:->string|\?)|numerator|odd\?|open-(?:input|output)-(?:bytevector|string)|or|output-port(?:-open\?|\?)|pair\?|peek-char|peek-u8|port\?|positive\?|procedure\?|quotient|raise|raise-continuable|rational\?|rationalize|read-(?:bytevector|bytevector!|char|error\?|line|string|u8)|real\?|remainder|reverse|round|set-c[ad]r!|square|string(?:->list|->number|->symbol|->utf8|->vector|-append|-copy|-copy!|-fill!|-for-each|-length|-map|-ref|-set!|\?|<\?|<=\?|=\?|>\?|>=\?)?|substring|symbol(?:->string|\?|=\?)|syntax-error|textual-port\?|truncate(?:-quotient|-remainder|\/)?|u8-ready\?|utf8->string|values|vector(?:->list|->string|-append|-copy|-copy!|-fill!|-for-each|-length|-map|-ref|-set!|\?)?|with-exception-handler|write-(?:bytevector|char|string|u8)|zero\?)(?=[()\[\]\s]|$)/,lookbehind:!0},operator:{pattern:/((?:^|[^'`#])[(\[])(?:[-+*%/]|[<>]=?|=>?)(?=[()\[\]\s]|$)/,lookbehind:!0},number:{pattern:RegExp(function(e){for(var r in e)e[r]=e[r].replace(/<[\w\s]+>/g,(function(r){return"(?:"+e[r].trim()+")"}));return e[r]}({"":/\d+(?:\/\d+)|(?:\d+(?:\.\d*)?|\.\d+)(?:[esfdl][+-]?\d+)?/.source,"":/[+-]?|[+-](?:inf|nan)\.0/.source,"":/[+-](?:|(?:inf|nan)\.0)?i/.source,"":/(?:@|)?|/.source,"":/(?:#d(?:#[ei])?|#[ei](?:#d)?)?/.source,"":/[0-9a-f]+(?:\/[0-9a-f]+)?/.source,"":/[+-]?|[+-](?:inf|nan)\.0/.source,"":/[+-](?:|(?:inf|nan)\.0)?i/.source,"":/(?:@|)?|/.source,"":/#[box](?:#[ei])?|(?:#[ei])?#[box]/.source,"":/(^|[()\[\]\s])(?:|)(?=[()\[\]\s]|$)/.source}),"i"),lookbehind:!0},boolean:{pattern:/(^|[()\[\]\s])#(?:[ft]|false|true)(?=[()\[\]\s]|$)/,lookbehind:!0},function:{pattern:/((?:^|[^'`#])[(\[])(?:[^|()\[\]'\s]+|\|(?:[^\\|]|\\.)*\|)(?=[()\[\]\s]|$)/,lookbehind:!0},identifier:{pattern:/(^|[()\[\]\s])\|(?:[^\\|]|\\.)*\|(?=[()\[\]\s]|$)/,lookbehind:!0,greedy:!0},punctuation:/[()\[\]']/}}(e)}e.exports=r,r.displayName="scheme",r.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/45685.47ca075a.chunk.js b/ydb/core/viewer/monitoring/static/js/45685.47ca075a.chunk.js new file mode 100644 index 000000000000..24ccdbff6fb9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/45685.47ca075a.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[45685],{45685:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-iq",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0634\u0628\u0627\u0637_\u0622\u0630\u0627\u0631_\u0646\u064a\u0633\u0627\u0646_\u0623\u064a\u0627\u0631_\u062d\u0632\u064a\u0631\u0627\u0646_\u062a\u0645\u0648\u0632_\u0622\u0628_\u0623\u064a\u0644\u0648\u0644_\u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u0623\u0648\u0644_ \u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u0623\u0648\u0644".split("_"),weekStart:1,weekdaysShort:"\u0623\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0623\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0634\u0628\u0627\u0637_\u0622\u0630\u0627\u0631_\u0646\u064a\u0633\u0627\u0646_\u0623\u064a\u0627\u0631_\u062d\u0632\u064a\u0631\u0627\u0646_\u062a\u0645\u0648\u0632_\u0622\u0628_\u0623\u064a\u0644\u0648\u0644_\u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u0623\u0648\u0644_ \u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u0623\u0648\u0644".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/45759.cb764ce8.chunk.js b/ydb/core/viewer/monitoring/static/js/45759.cb764ce8.chunk.js new file mode 100644 index 000000000000..e99df6df25a1 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/45759.cb764ce8.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[45759],{45759:function(a,e,t){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var t=e(a),_={name:"eu",weekdays:"igandea_astelehena_asteartea_asteazkena_osteguna_ostirala_larunbata".split("_"),months:"urtarrila_otsaila_martxoa_apirila_maiatza_ekaina_uztaila_abuztua_iraila_urria_azaroa_abendua".split("_"),weekStart:1,weekdaysShort:"ig._al._ar._az._og._ol._lr.".split("_"),monthsShort:"urt._ots._mar._api._mai._eka._uzt._abu._ira._urr._aza._abe.".split("_"),weekdaysMin:"ig_al_ar_az_og_ol_lr".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY[ko] MMMM[ren] D[a]",LLL:"YYYY[ko] MMMM[ren] D[a] HH:mm",LLLL:"dddd, YYYY[ko] MMMM[ren] D[a] HH:mm",l:"YYYY-M-D",ll:"YYYY[ko] MMM D[a]",lll:"YYYY[ko] MMM D[a] HH:mm",llll:"ddd, YYYY[ko] MMM D[a] HH:mm"},relativeTime:{future:"%s barru",past:"duela %s",s:"segundo batzuk",m:"minutu bat",mm:"%d minutu",h:"ordu bat",hh:"%d ordu",d:"egun bat",dd:"%d egun",M:"hilabete bat",MM:"%d hilabete",y:"urte bat",yy:"%d urte"}};return t.default.locale(_,null,!0),_}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4582.5bf174ff.chunk.js b/ydb/core/viewer/monitoring/static/js/4582.5bf174ff.chunk.js deleted file mode 100644 index 2c7a5fb8af79..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4582.5bf174ff.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4582.5bf174ff.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4582],{84582:(e,_,t)=>{t.r(_),t.d(_,{conf:()=>s,language:()=>r});var s={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},r={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ALL","ANALYSE","ANALYZE","AND","ANY","ARRAY","AS","ASC","ASYMMETRIC","AUTHORIZATION","BINARY","BOTH","CASE","CAST","CHECK","COLLATE","COLLATION","COLUMN","CONCURRENTLY","CONSTRAINT","CREATE","CROSS","CURRENT_CATALOG","CURRENT_DATE","CURRENT_ROLE","CURRENT_SCHEMA","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","DEFAULT","DEFERRABLE","DESC","DISTINCT","DO","ELSE","END","EXCEPT","FALSE","FETCH","FOR","FOREIGN","FREEZE","FROM","FULL","GRANT","GROUP","HAVING","ILIKE","IN","INITIALLY","INNER","INTERSECT","INTO","IS","ISNULL","JOIN","LATERAL","LEADING","LEFT","LIKE","LIMIT","LOCALTIME","LOCALTIMESTAMP","NATURAL","NOT","NOTNULL","NULL","OFFSET","ON","ONLY","OR","ORDER","OUTER","OVERLAPS","PLACING","PRIMARY","REFERENCES","RETURNING","RIGHT","SELECT","SESSION_USER","SIMILAR","SOME","SYMMETRIC","TABLE","TABLESAMPLE","THEN","TO","TRAILING","TRUE","UNION","UNIQUE","USER","USING","VARIADIC","VERBOSE","WHEN","WHERE","WINDOW","WITH"],operators:["AND","BETWEEN","IN","LIKE","NOT","OR","IS","NULL","INTERSECT","UNION","INNER","JOIN","LEFT","OUTER","RIGHT"],builtinFunctions:["abbrev","abs","acldefault","aclexplode","acos","acosd","acosh","age","any","area","array_agg","array_append","array_cat","array_dims","array_fill","array_length","array_lower","array_ndims","array_position","array_positions","array_prepend","array_remove","array_replace","array_to_json","array_to_string","array_to_tsvector","array_upper","ascii","asin","asind","asinh","atan","atan2","atan2d","atand","atanh","avg","bit","bit_and","bit_count","bit_length","bit_or","bit_xor","bool_and","bool_or","bound_box","box","brin_desummarize_range","brin_summarize_new_values","brin_summarize_range","broadcast","btrim","cardinality","cbrt","ceil","ceiling","center","char_length","character_length","chr","circle","clock_timestamp","coalesce","col_description","concat","concat_ws","convert","convert_from","convert_to","corr","cos","cosd","cosh","cot","cotd","count","covar_pop","covar_samp","cume_dist","current_catalog","current_database","current_date","current_query","current_role","current_schema","current_schemas","current_setting","current_time","current_timestamp","current_user","currval","cursor_to_xml","cursor_to_xmlschema","date_bin","date_part","date_trunc","database_to_xml","database_to_xml_and_xmlschema","database_to_xmlschema","decode","degrees","dense_rank","diagonal","diameter","div","encode","enum_first","enum_last","enum_range","every","exp","extract","factorial","family","first_value","floor","format","format_type","gcd","gen_random_uuid","generate_series","generate_subscripts","get_bit","get_byte","get_current_ts_config","gin_clean_pending_list","greatest","grouping","has_any_column_privilege","has_column_privilege","has_database_privilege","has_foreign_data_wrapper_privilege","has_function_privilege","has_language_privilege","has_schema_privilege","has_sequence_privilege","has_server_privilege","has_table_privilege","has_tablespace_privilege","has_type_privilege","height","host","hostmask","inet_client_addr","inet_client_port","inet_merge","inet_same_family","inet_server_addr","inet_server_port","initcap","isclosed","isempty","isfinite","isopen","json_agg","json_array_elements","json_array_elements_text","json_array_length","json_build_array","json_build_object","json_each","json_each_text","json_extract_path","json_extract_path_text","json_object","json_object_agg","json_object_keys","json_populate_record","json_populate_recordset","json_strip_nulls","json_to_record","json_to_recordset","json_to_tsvector","json_typeof","jsonb_agg","jsonb_array_elements","jsonb_array_elements_text","jsonb_array_length","jsonb_build_array","jsonb_build_object","jsonb_each","jsonb_each_text","jsonb_extract_path","jsonb_extract_path_text","jsonb_insert","jsonb_object","jsonb_object_agg","jsonb_object_keys","jsonb_path_exists","jsonb_path_match","jsonb_path_query","jsonb_path_query_array","jsonb_path_exists_tz","jsonb_path_query_first","jsonb_path_query_array_tz","jsonb_path_query_first_tz","jsonb_path_query_tz","jsonb_path_match_tz","jsonb_populate_record","jsonb_populate_recordset","jsonb_pretty","jsonb_set","jsonb_set_lax","jsonb_strip_nulls","jsonb_to_record","jsonb_to_recordset","jsonb_to_tsvector","jsonb_typeof","justify_days","justify_hours","justify_interval","lag","last_value","lastval","lcm","lead","least","left","length","line","ln","localtime","localtimestamp","log","log10","lower","lower_inc","lower_inf","lpad","lseg","ltrim","macaddr8_set7bit","make_date","make_interval","make_time","make_timestamp","make_timestamptz","makeaclitem","masklen","max","md5","min","min_scale","mod","mode","multirange","netmask","network","nextval","normalize","now","npoints","nth_value","ntile","nullif","num_nonnulls","num_nulls","numnode","obj_description","octet_length","overlay","parse_ident","path","pclose","percent_rank","percentile_cont","percentile_disc","pg_advisory_lock","pg_advisory_lock_shared","pg_advisory_unlock","pg_advisory_unlock_all","pg_advisory_unlock_shared","pg_advisory_xact_lock","pg_advisory_xact_lock_shared","pg_backend_pid","pg_backup_start_time","pg_blocking_pids","pg_cancel_backend","pg_client_encoding","pg_collation_actual_version","pg_collation_is_visible","pg_column_compression","pg_column_size","pg_conf_load_time","pg_control_checkpoint","pg_control_init","pg_control_recovery","pg_control_system","pg_conversion_is_visible","pg_copy_logical_replication_slot","pg_copy_physical_replication_slot","pg_create_logical_replication_slot","pg_create_physical_replication_slot","pg_create_restore_point","pg_current_logfile","pg_current_snapshot","pg_current_wal_flush_lsn","pg_current_wal_insert_lsn","pg_current_wal_lsn","pg_current_xact_id","pg_current_xact_id_if_assigned","pg_current_xlog_flush_location","pg_current_xlog_insert_location","pg_current_xlog_location","pg_database_size","pg_describe_object","pg_drop_replication_slot","pg_event_trigger_ddl_commands","pg_event_trigger_dropped_objects","pg_event_trigger_table_rewrite_oid","pg_event_trigger_table_rewrite_reason","pg_export_snapshot","pg_filenode_relation","pg_function_is_visible","pg_get_catalog_foreign_keys","pg_get_constraintdef","pg_get_expr","pg_get_function_arguments","pg_get_function_identity_arguments","pg_get_function_result","pg_get_functiondef","pg_get_indexdef","pg_get_keywords","pg_get_object_address","pg_get_owned_sequence","pg_get_ruledef","pg_get_serial_sequence","pg_get_statisticsobjdef","pg_get_triggerdef","pg_get_userbyid","pg_get_viewdef","pg_get_wal_replay_pause_state","pg_has_role","pg_identify_object","pg_identify_object_as_address","pg_import_system_collations","pg_index_column_has_property","pg_index_has_property","pg_indexam_has_property","pg_indexes_size","pg_is_in_backup","pg_is_in_recovery","pg_is_other_temp_schema","pg_is_wal_replay_paused","pg_is_xlog_replay_paused","pg_jit_available","pg_last_committed_xact","pg_last_wal_receive_lsn","pg_last_wal_replay_lsn","pg_last_xact_replay_timestamp","pg_last_xlog_receive_location","pg_last_xlog_replay_location","pg_listening_channels","pg_log_backend_memory_contexts","pg_logical_emit_message","pg_logical_slot_get_binary_changes","pg_logical_slot_get_changes","pg_logical_slot_peek_binary_changes","pg_logical_slot_peek_changes","pg_ls_archive_statusdir","pg_ls_dir","pg_ls_logdir","pg_ls_tmpdir","pg_ls_waldir","pg_mcv_list_items","pg_my_temp_schema","pg_notification_queue_usage","pg_opclass_is_visible","pg_operator_is_visible","pg_opfamily_is_visible","pg_options_to_table","pg_partition_ancestors","pg_partition_root","pg_partition_tree","pg_postmaster_start_time","pg_promote","pg_read_binary_file","pg_read_file","pg_relation_filenode","pg_relation_filepath","pg_relation_size","pg_reload_conf","pg_replication_origin_advance","pg_replication_origin_create","pg_replication_origin_drop","pg_replication_origin_oid","pg_replication_origin_progress","pg_replication_origin_session_is_setup","pg_replication_origin_session_progress","pg_replication_origin_session_reset","pg_replication_origin_session_setup","pg_replication_origin_xact_reset","pg_replication_origin_xact_setup","pg_replication_slot_advance","pg_rotate_logfile","pg_safe_snapshot_blocking_pids","pg_size_bytes","pg_size_pretty","pg_sleep","pg_sleep_for","pg_sleep_until","pg_snapshot_xip","pg_snapshot_xmax","pg_snapshot_xmin","pg_start_backup","pg_stat_file","pg_statistics_obj_is_visible","pg_stop_backup","pg_switch_wal","pg_switch_xlog","pg_table_is_visible","pg_table_size","pg_tablespace_databases","pg_tablespace_location","pg_tablespace_size","pg_terminate_backend","pg_total_relation_size","pg_trigger_depth","pg_try_advisory_lock","pg_try_advisory_lock_shared","pg_try_advisory_xact_lock","pg_try_advisory_xact_lock_shared","pg_ts_config_is_visible","pg_ts_dict_is_visible","pg_ts_parser_is_visible","pg_ts_template_is_visible","pg_type_is_visible","pg_typeof","pg_visible_in_snapshot","pg_wal_lsn_diff","pg_wal_replay_pause","pg_wal_replay_resume","pg_walfile_name","pg_walfile_name_offset","pg_xact_commit_timestamp","pg_xact_commit_timestamp_origin","pg_xact_status","pg_xlog_location_diff","pg_xlog_replay_pause","pg_xlog_replay_resume","pg_xlogfile_name","pg_xlogfile_name_offset","phraseto_tsquery","pi","plainto_tsquery","point","polygon","popen","position","power","pqserverversion","query_to_xml","query_to_xml_and_xmlschema","query_to_xmlschema","querytree","quote_ident","quote_literal","quote_nullable","radians","radius","random","range_agg","range_intersect_agg","range_merge","rank","regexp_count","regexp_instr","regexp_like","regexp_match","regexp_matches","regexp_replace","regexp_split_to_array","regexp_split_to_table","regexp_substr","regr_avgx","regr_avgy","regr_count","regr_intercept","regr_r2","regr_slope","regr_sxx","regr_sxy","regr_syy","repeat","replace","reverse","right","round","row_number","row_security_active","row_to_json","rpad","rtrim","scale","schema_to_xml","schema_to_xml_and_xmlschema","schema_to_xmlschema","session_user","set_bit","set_byte","set_config","set_masklen","setseed","setval","setweight","sha224","sha256","sha384","sha512","shobj_description","sign","sin","sind","sinh","slope","split_part","sprintf","sqrt","starts_with","statement_timestamp","stddev","stddev_pop","stddev_samp","string_agg","string_to_array","string_to_table","strip","strpos","substr","substring","sum","suppress_redundant_updates_trigger","table_to_xml","table_to_xml_and_xmlschema","table_to_xmlschema","tan","tand","tanh","text","timeofday","timezone","to_ascii","to_char","to_date","to_hex","to_json","to_number","to_regclass","to_regcollation","to_regnamespace","to_regoper","to_regoperator","to_regproc","to_regprocedure","to_regrole","to_regtype","to_timestamp","to_tsquery","to_tsvector","transaction_timestamp","translate","trim","trim_array","trim_scale","trunc","ts_debug","ts_delete","ts_filter","ts_headline","ts_lexize","ts_parse","ts_rank","ts_rank_cd","ts_rewrite","ts_stat","ts_token_type","tsquery_phrase","tsvector_to_array","tsvector_update_trigger","tsvector_update_trigger_column","txid_current","txid_current_if_assigned","txid_current_snapshot","txid_snapshot_xip","txid_snapshot_xmax","txid_snapshot_xmin","txid_status","txid_visible_in_snapshot","unistr","unnest","upper","upper_inc","upper_inf","user","var_pop","var_samp","variance","version","websearch_to_tsquery","width","width_bucket","xml_is_well_formed","xml_is_well_formed_content","xml_is_well_formed_document","xmlagg","xmlcomment","xmlconcat","xmlelement","xmlexists","xmlforest","xmlparse","xmlpi","xmlroot","xmlserialize","xpath","xpath_exists"],builtinVariables:[],pseudoColumns:[],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@keywords":"keyword","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],complexIdentifiers:[[/"/,{token:"identifier.quote",next:"@quotedIdentifier"}]],quotedIdentifier:[[/[^"]+/,"identifier"],[/""/,"identifier"],[/"/,{token:"identifier.quote",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4601.39745c4e.chunk.js b/ydb/core/viewer/monitoring/static/js/4601.39745c4e.chunk.js deleted file mode 100644 index 40d48f1e56cf..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4601.39745c4e.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4601],{44601:function(a,j,r){a.exports=function(a){"use strict";function j(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var r=j(a),_={name:"tlh",weekdays:"lojmItjaj_DaSjaj_povjaj_ghItlhjaj_loghjaj_buqjaj_ghInjaj".split("_"),months:"tera\u2019 jar wa\u2019_tera\u2019 jar cha\u2019_tera\u2019 jar wej_tera\u2019 jar loS_tera\u2019 jar vagh_tera\u2019 jar jav_tera\u2019 jar Soch_tera\u2019 jar chorgh_tera\u2019 jar Hut_tera\u2019 jar wa\u2019maH_tera\u2019 jar wa\u2019maH wa\u2019_tera\u2019 jar wa\u2019maH cha\u2019".split("_"),weekStart:1,weekdaysShort:"lojmItjaj_DaSjaj_povjaj_ghItlhjaj_loghjaj_buqjaj_ghInjaj".split("_"),monthsShort:"jar wa\u2019_jar cha\u2019_jar wej_jar loS_jar vagh_jar jav_jar Soch_jar chorgh_jar Hut_jar wa\u2019maH_jar wa\u2019maH wa\u2019_jar wa\u2019maH cha\u2019".split("_"),weekdaysMin:"lojmItjaj_DaSjaj_povjaj_ghItlhjaj_loghjaj_buqjaj_ghInjaj".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"}};return r.default.locale(_,null,!0),_}(r(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/46012.36fc4080.chunk.js b/ydb/core/viewer/monitoring/static/js/46012.36fc4080.chunk.js new file mode 100644 index 000000000000..b22df51e9313 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/46012.36fc4080.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 46012.36fc4080.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[46012],{46012:(e,s,o)=>{o.r(s),o.d(s,{conf:()=>n,language:()=>l});var n={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},l={defaultToken:"",tokenPostfix:".dockerfile",variable:/\${?[\w]+}?/,tokenizer:{root:[{include:"@whitespace"},{include:"@comment"},[/(ONBUILD)(\s+)/,["keyword",""]],[/(ENV)(\s+)([\w]+)/,["keyword","",{token:"variable",next:"@arguments"}]],[/(FROM|MAINTAINER|RUN|EXPOSE|ENV|ADD|ARG|VOLUME|LABEL|USER|WORKDIR|COPY|CMD|STOPSIGNAL|SHELL|HEALTHCHECK|ENTRYPOINT)/,{token:"keyword",next:"@arguments"}]],arguments:[{include:"@whitespace"},{include:"@strings"},[/(@variable)/,{cases:{"@eos":{token:"variable",next:"@popall"},"@default":"variable"}}],[/\\/,{cases:{"@eos":"","@default":""}}],[/./,{cases:{"@eos":{token:"",next:"@popall"},"@default":""}}]],whitespace:[[/\s+/,{cases:{"@eos":{token:"",next:"@popall"},"@default":""}}]],comment:[[/(^#.*$)/,"comment","@popall"]],strings:[[/\\'$/,"","@popall"],[/\\'/,""],[/'$/,"string","@popall"],[/'/,"string","@stringBody"],[/"$/,"string","@popall"],[/"/,"string","@dblStringBody"]],stringBody:[[/[^\\\$']/,{cases:{"@eos":{token:"string",next:"@popall"},"@default":"string"}}],[/\\./,"string.escape"],[/'$/,"string","@popall"],[/'/,"string","@pop"],[/(@variable)/,"variable"],[/\\$/,"string"],[/$/,"string","@popall"]],dblStringBody:[[/[^\\\$"]/,{cases:{"@eos":{token:"string",next:"@popall"},"@default":"string"}}],[/\\./,"string.escape"],[/"$/,"string","@popall"],[/"/,"string","@pop"],[/(@variable)/,"variable"],[/\\$/,"string"],[/$/,"string","@popall"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4582.5bf174ff.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/46012.36fc4080.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/4582.5bf174ff.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/46012.36fc4080.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/46047.240cef79.chunk.js b/ydb/core/viewer/monitoring/static/js/46047.240cef79.chunk.js new file mode 100644 index 000000000000..96421b4ea349 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/46047.240cef79.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[46047],{46047:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e);function r(e){return e>1&&e<5&&1!=~~(e/10)}function s(e,n,t,s){var _=e+" ";switch(t){case"s":return n||s?"p\xe1r sekund":"p\xe1r sekundami";case"m":return n?"minuta":s?"minutu":"minutou";case"mm":return n||s?_+(r(e)?"minuty":"minut"):_+"minutami";case"h":return n?"hodina":s?"hodinu":"hodinou";case"hh":return n||s?_+(r(e)?"hodiny":"hodin"):_+"hodinami";case"d":return n||s?"den":"dnem";case"dd":return n||s?_+(r(e)?"dny":"dn\xed"):_+"dny";case"M":return n||s?"m\u011bs\xedc":"m\u011bs\xedcem";case"MM":return n||s?_+(r(e)?"m\u011bs\xedce":"m\u011bs\xedc\u016f"):_+"m\u011bs\xedci";case"y":return n||s?"rok":"rokem";case"yy":return n||s?_+(r(e)?"roky":"let"):_+"lety"}}var _={name:"cs",weekdays:"ned\u011ble_pond\u011bl\xed_\xfater\xfd_st\u0159eda_\u010dtvrtek_p\xe1tek_sobota".split("_"),weekdaysShort:"ne_po_\xfat_st_\u010dt_p\xe1_so".split("_"),weekdaysMin:"ne_po_\xfat_st_\u010dt_p\xe1_so".split("_"),months:"leden_\xfanor_b\u0159ezen_duben_kv\u011bten_\u010derven_\u010dervenec_srpen_z\xe1\u0159\xed_\u0159\xedjen_listopad_prosinec".split("_"),monthsShort:"led_\xfano_b\u0159e_dub_kv\u011b_\u010dvn_\u010dvc_srp_z\xe1\u0159_\u0159\xedj_lis_pro".split("_"),weekStart:1,yearStart:4,ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd D. MMMM YYYY H:mm",l:"D. M. YYYY"},relativeTime:{future:"za %s",past:"p\u0159ed %s",s:s,m:s,mm:s,h:s,hh:s,d:s,dd:s,M:s,MM:s,y:s,yy:s}};return t.default.locale(_,null,!0),_}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/46134.708fa2c1.chunk.js b/ydb/core/viewer/monitoring/static/js/46134.708fa2c1.chunk.js new file mode 100644 index 000000000000..6462d78e9042 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/46134.708fa2c1.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[46134],{15657:e=>{function t(e){e.languages.swift={comment:{pattern:/(^|[^\\:])(?:\/\/.*|\/\*(?:[^/*]|\/(?!\*)|\*(?!\/)|\/\*(?:[^*]|\*(?!\/))*\*\/)*\*\/)/,lookbehind:!0,greedy:!0},"string-literal":[{pattern:RegExp(/(^|[^"#])/.source+"(?:"+/"(?:\\(?:\((?:[^()]|\([^()]*\))*\)|\r\n|[^(])|[^\\\r\n"])*"/.source+"|"+/"""(?:\\(?:\((?:[^()]|\([^()]*\))*\)|[^(])|[^\\"]|"(?!""))*"""/.source+")"+/(?!["#])/.source),lookbehind:!0,greedy:!0,inside:{interpolation:{pattern:/(\\\()(?:[^()]|\([^()]*\))*(?=\))/,lookbehind:!0,inside:null},"interpolation-punctuation":{pattern:/^\)|\\\($/,alias:"punctuation"},punctuation:/\\(?=[\r\n])/,string:/[\s\S]+/}},{pattern:RegExp(/(^|[^"#])(#+)/.source+"(?:"+/"(?:\\(?:#+\((?:[^()]|\([^()]*\))*\)|\r\n|[^#])|[^\\\r\n])*?"/.source+"|"+/"""(?:\\(?:#+\((?:[^()]|\([^()]*\))*\)|[^#])|[^\\])*?"""/.source+")\\2"),lookbehind:!0,greedy:!0,inside:{interpolation:{pattern:/(\\#+\()(?:[^()]|\([^()]*\))*(?=\))/,lookbehind:!0,inside:null},"interpolation-punctuation":{pattern:/^\)|\\#+\($/,alias:"punctuation"},string:/[\s\S]+/}}],directive:{pattern:RegExp(/#/.source+"(?:"+/(?:elseif|if)\b/.source+"(?:[ \t]*"+/(?:![ \t]*)?(?:\b\w+\b(?:[ \t]*\((?:[^()]|\([^()]*\))*\))?|\((?:[^()]|\([^()]*\))*\))(?:[ \t]*(?:&&|\|\|))?/.source+")+|"+/(?:else|endif)\b/.source+")"),alias:"property",inside:{"directive-name":/^#\w+/,boolean:/\b(?:false|true)\b/,number:/\b\d+(?:\.\d+)*\b/,operator:/!|&&|\|\||[<>]=?/,punctuation:/[(),]/}},literal:{pattern:/#(?:colorLiteral|column|dsohandle|file(?:ID|Literal|Path)?|function|imageLiteral|line)\b/,alias:"constant"},"other-directive":{pattern:/#\w+\b/,alias:"property"},attribute:{pattern:/@\w+/,alias:"atrule"},"function-definition":{pattern:/(\bfunc\s+)\w+/,lookbehind:!0,alias:"function"},label:{pattern:/\b(break|continue)\s+\w+|\b[a-zA-Z_]\w*(?=\s*:\s*(?:for|repeat|while)\b)/,lookbehind:!0,alias:"important"},keyword:/\b(?:Any|Protocol|Self|Type|actor|as|assignment|associatedtype|associativity|async|await|break|case|catch|class|continue|convenience|default|defer|deinit|didSet|do|dynamic|else|enum|extension|fallthrough|fileprivate|final|for|func|get|guard|higherThan|if|import|in|indirect|infix|init|inout|internal|is|isolated|lazy|left|let|lowerThan|mutating|none|nonisolated|nonmutating|open|operator|optional|override|postfix|precedencegroup|prefix|private|protocol|public|repeat|required|rethrows|return|right|safe|self|set|some|static|struct|subscript|super|switch|throw|throws|try|typealias|unowned|unsafe|var|weak|where|while|willSet)\b/,boolean:/\b(?:false|true)\b/,nil:{pattern:/\bnil\b/,alias:"constant"},"short-argument":/\$\d+\b/,omit:{pattern:/\b_\b/,alias:"keyword"},number:/\b(?:[\d_]+(?:\.[\de_]+)?|0x[a-f0-9_]+(?:\.[a-f0-9p_]+)?|0b[01_]+|0o[0-7_]+)\b/i,"class-name":/\b[A-Z](?:[A-Z_\d]*[a-z]\w*)?\b/,function:/\b[a-z_]\w*(?=\s*\()/i,constant:/\b(?:[A-Z_]{2,}|k[A-Z][A-Za-z_]+)\b/,operator:/[-+*/%=!<>&|^~?]+|\.[.\-+*/%=!<>&|^~?]+/,punctuation:/[{}[\]();,.:\\]/},e.languages.swift["string-literal"].forEach((function(t){t.inside.interpolation.inside=e.languages.swift}))}e.exports=t,t.displayName="swift",t.aliases=[]},46134:(e,t,n)=>{n.d(t,{default:()=>a});var i=n(15657);const a=n.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4617.be8c65cd.chunk.js b/ydb/core/viewer/monitoring/static/js/4617.be8c65cd.chunk.js new file mode 100644 index 000000000000..ec20f13278e7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/4617.be8c65cd.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4617],{4617:(e,a,n)=>{n.d(a,{default:()=>s});var t=n(75486);const s=n.n(t)()},75486:e=>{function a(e){e.languages.kusto={comment:{pattern:/\/\/.*/,greedy:!0},string:{pattern:/```[\s\S]*?```|[hH]?(?:"(?:[^\r\n\\"]|\\.)*"|'(?:[^\r\n\\']|\\.)*'|@(?:"[^\r\n"]*"|'[^\r\n']*'))/,greedy:!0},verb:{pattern:/(\|\s*)[a-z][\w-]*/i,lookbehind:!0,alias:"keyword"},command:{pattern:/\.[a-z][a-z\d-]*\b/,alias:"keyword"},"class-name":/\b(?:bool|datetime|decimal|dynamic|guid|int|long|real|string|timespan)\b/,keyword:/\b(?:access|alias|and|anti|as|asc|auto|between|by|(?:contains|(?:ends|starts)with|has(?:perfix|suffix)?)(?:_cs)?|database|declare|desc|external|from|fullouter|has_all|in|ingestion|inline|inner|innerunique|into|(?:left|right)(?:anti(?:semi)?|inner|outer|semi)?|let|like|local|not|of|on|or|pattern|print|query_parameters|range|restrict|schema|set|step|table|tables|to|view|where|with|matches\s+regex|nulls\s+(?:first|last))(?![\w-])/,boolean:/\b(?:false|null|true)\b/,function:/\b[a-z_]\w*(?=\s*\()/,datetime:[{pattern:/\b(?:(?:Fri|Friday|Mon|Monday|Sat|Saturday|Sun|Sunday|Thu|Thursday|Tue|Tuesday|Wed|Wednesday)\s*,\s*)?\d{1,2}(?:\s+|-)(?:Apr|Aug|Dec|Feb|Jan|Jul|Jun|Mar|May|Nov|Oct|Sep)(?:\s+|-)\d{2}\s+\d{2}:\d{2}(?::\d{2})?(?:\s*(?:\b(?:[A-Z]|(?:[ECMT][DS]|GM|U)T)|[+-]\d{4}))?\b/,alias:"number"},{pattern:/[+-]?\b(?:\d{4}-\d{2}-\d{2}(?:[ T]\d{2}:\d{2}(?::\d{2}(?:\.\d+)?)?)?|\d{2}:\d{2}(?::\d{2}(?:\.\d+)?)?)Z?/,alias:"number"}],number:/\b(?:0x[0-9A-Fa-f]+|\d+(?:\.\d+)?(?:[Ee][+-]?\d+)?)(?:(?:min|sec|[mn\xb5]s|[dhms]|microsecond|tick)\b)?|[+-]?\binf\b/,operator:/=>|[!=]~|[!=<>]=?|[-+*/%|]|\.\./,punctuation:/[()\[\]{},;.:]/}}e.exports=a,a.displayName="kusto",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/46306.d3a5a75d.chunk.js b/ydb/core/viewer/monitoring/static/js/46306.d3a5a75d.chunk.js new file mode 100644 index 000000000000..dacaa8d549fb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/46306.d3a5a75d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[46306],{46306:(e,s,n)=>{n.d(s,{default:()=>a});var r=n(90323);const a=n.n(r)()},90323:e=>{function s(e){!function(e){function s(e,s){return e.replace(/<<(\d+)>>/g,(function(e,n){return"(?:"+s[+n]+")"}))}function n(e,n,r){return RegExp(s(e,n),r||"")}function r(e,s){for(var n=0;n>/g,(function(){return"(?:"+e+")"}));return e.replace(/<>/g,"[^\\s\\S]")}var a="bool byte char decimal double dynamic float int long object sbyte short string uint ulong ushort var void",t="class enum interface record struct",o="add alias and ascending async await by descending from(?=\\s*(?:\\w|$)) get global group into init(?=\\s*;) join let nameof not notnull on or orderby partial remove select set unmanaged value when where with(?=\\s*{)",i="abstract as base break case catch checked const continue default delegate do else event explicit extern finally fixed for foreach goto if implicit in internal is lock namespace new null operator out override params private protected public readonly ref return sealed sizeof stackalloc static switch this throw try typeof unchecked unsafe using virtual volatile while yield";function c(e){return"\\b(?:"+e.trim().replace(/ /g,"|")+")\\b"}var u=c(t),l=RegExp(c(a+" "+t+" "+o+" "+i)),d=c(t+" "+o+" "+i),p=c(a+" "+t+" "+i),g=r(/<(?:[^<>;=+\-*/%&|^]|<>)*>/.source,2),b=r(/\((?:[^()]|<>)*\)/.source,2),h=/@?\b[A-Za-z_]\w*\b/.source,f=s(/<<0>>(?:\s*<<1>>)?/.source,[h,g]),m=s(/(?!<<0>>)<<1>>(?:\s*\.\s*<<1>>)*/.source,[d,f]),k=/\[\s*(?:,\s*)*\]/.source,y=s(/<<0>>(?:\s*(?:\?\s*)?<<1>>)*(?:\s*\?)?/.source,[m,k]),w=s(/[^,()<>[\];=+\-*/%&|^]|<<0>>|<<1>>|<<2>>/.source,[g,b,k]),v=s(/\(<<0>>+(?:,<<0>>+)+\)/.source,[w]),x=s(/(?:<<0>>|<<1>>)(?:\s*(?:\?\s*)?<<2>>)*(?:\s*\?)?/.source,[v,m,k]),_={keyword:l,punctuation:/[<>()?,.:[\]]/},$=/'(?:[^\r\n'\\]|\\.|\\[Uux][\da-fA-F]{1,8})'/.source,B=/"(?:\\.|[^\\"\r\n])*"/.source,E=/@"(?:""|\\[\s\S]|[^\\"])*"(?!")/.source;e.languages.csharp=e.languages.extend("clike",{string:[{pattern:n(/(^|[^$\\])<<0>>/.source,[E]),lookbehind:!0,greedy:!0},{pattern:n(/(^|[^@$\\])<<0>>/.source,[B]),lookbehind:!0,greedy:!0}],"class-name":[{pattern:n(/(\busing\s+static\s+)<<0>>(?=\s*;)/.source,[m]),lookbehind:!0,inside:_},{pattern:n(/(\busing\s+<<0>>\s*=\s*)<<1>>(?=\s*;)/.source,[h,x]),lookbehind:!0,inside:_},{pattern:n(/(\busing\s+)<<0>>(?=\s*=)/.source,[h]),lookbehind:!0},{pattern:n(/(\b<<0>>\s+)<<1>>/.source,[u,f]),lookbehind:!0,inside:_},{pattern:n(/(\bcatch\s*\(\s*)<<0>>/.source,[m]),lookbehind:!0,inside:_},{pattern:n(/(\bwhere\s+)<<0>>/.source,[h]),lookbehind:!0},{pattern:n(/(\b(?:is(?:\s+not)?|as)\s+)<<0>>/.source,[y]),lookbehind:!0,inside:_},{pattern:n(/\b<<0>>(?=\s+(?!<<1>>|with\s*\{)<<2>>(?:\s*[=,;:{)\]]|\s+(?:in|when)\b))/.source,[x,p,h]),inside:_}],keyword:l,number:/(?:\b0(?:x[\da-f_]*[\da-f]|b[01_]*[01])|(?:\B\.\d+(?:_+\d+)*|\b\d+(?:_+\d+)*(?:\.\d+(?:_+\d+)*)?)(?:e[-+]?\d+(?:_+\d+)*)?)(?:[dflmu]|lu|ul)?\b/i,operator:/>>=?|<<=?|[-=]>|([-+&|])\1|~|\?\?=?|[-+*/%&|^!=<>]=?/,punctuation:/\?\.?|::|[{}[\];(),.:]/}),e.languages.insertBefore("csharp","number",{range:{pattern:/\.\./,alias:"operator"}}),e.languages.insertBefore("csharp","punctuation",{"named-parameter":{pattern:n(/([(,]\s*)<<0>>(?=\s*:)/.source,[h]),lookbehind:!0,alias:"punctuation"}}),e.languages.insertBefore("csharp","class-name",{namespace:{pattern:n(/(\b(?:namespace|using)\s+)<<0>>(?:\s*\.\s*<<0>>)*(?=\s*[;{])/.source,[h]),lookbehind:!0,inside:{punctuation:/\./}},"type-expression":{pattern:n(/(\b(?:default|sizeof|typeof)\s*\(\s*(?!\s))(?:[^()\s]|\s(?!\s)|<<0>>)*(?=\s*\))/.source,[b]),lookbehind:!0,alias:"class-name",inside:_},"return-type":{pattern:n(/<<0>>(?=\s+(?:<<1>>\s*(?:=>|[({]|\.\s*this\s*\[)|this\s*\[))/.source,[x,m]),inside:_,alias:"class-name"},"constructor-invocation":{pattern:n(/(\bnew\s+)<<0>>(?=\s*[[({])/.source,[x]),lookbehind:!0,inside:_,alias:"class-name"},"generic-method":{pattern:n(/<<0>>\s*<<1>>(?=\s*\()/.source,[h,g]),inside:{function:n(/^<<0>>/.source,[h]),generic:{pattern:RegExp(g),alias:"class-name",inside:_}}},"type-list":{pattern:n(/\b((?:<<0>>\s+<<1>>|record\s+<<1>>\s*<<5>>|where\s+<<2>>)\s*:\s*)(?:<<3>>|<<4>>|<<1>>\s*<<5>>|<<6>>)(?:\s*,\s*(?:<<3>>|<<4>>|<<6>>))*(?=\s*(?:where|[{;]|=>|$))/.source,[u,f,h,x,l.source,b,/\bnew\s*\(\s*\)/.source]),lookbehind:!0,inside:{"record-arguments":{pattern:n(/(^(?!new\s*\()<<0>>\s*)<<1>>/.source,[f,b]),lookbehind:!0,greedy:!0,inside:e.languages.csharp},keyword:l,"class-name":{pattern:RegExp(x),greedy:!0,inside:_},punctuation:/[,()]/}},preprocessor:{pattern:/(^[\t ]*)#.*/m,lookbehind:!0,alias:"property",inside:{directive:{pattern:/(#)\b(?:define|elif|else|endif|endregion|error|if|line|nullable|pragma|region|undef|warning)\b/,lookbehind:!0,alias:"keyword"}}}});var R=B+"|"+$,S=s(/\/(?![*/])|\/\/[^\r\n]*[\r\n]|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>/.source,[R]),z=r(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[S]),2),j=/\b(?:assembly|event|field|method|module|param|property|return|type)\b/.source,A=s(/<<0>>(?:\s*\(<<1>>*\))?/.source,[m,z]);e.languages.insertBefore("csharp","class-name",{attribute:{pattern:n(/((?:^|[^\s\w>)?])\s*\[\s*)(?:<<0>>\s*:\s*)?<<1>>(?:\s*,\s*<<1>>)*(?=\s*\])/.source,[j,A]),lookbehind:!0,greedy:!0,inside:{target:{pattern:n(/^<<0>>(?=\s*:)/.source,[j]),alias:"keyword"},"attribute-arguments":{pattern:n(/\(<<0>>*\)/.source,[z]),inside:e.languages.csharp},"class-name":{pattern:RegExp(m),inside:{punctuation:/\./}},punctuation:/[:,]/}}});var C=/:[^}\r\n]+/.source,T=r(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[S]),2),F=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[T,C]),N=r(s(/[^"'/()]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>|\(<>*\)/.source,[R]),2),U=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[N,C]);function Z(s,r){return{interpolation:{pattern:n(/((?:^|[^{])(?:\{\{)*)<<0>>/.source,[s]),lookbehind:!0,inside:{"format-string":{pattern:n(/(^\{(?:(?![}:])<<0>>)*)<<1>>(?=\}$)/.source,[r,C]),lookbehind:!0,inside:{punctuation:/^:/}},punctuation:/^\{|\}$/,expression:{pattern:/[\s\S]+/,alias:"language-csharp",inside:e.languages.csharp}}},string:/[\s\S]+/}}e.languages.insertBefore("csharp","string",{"interpolation-string":[{pattern:n(/(^|[^\\])(?:\$@|@\$)"(?:""|\\[\s\S]|\{\{|<<0>>|[^\\{"])*"/.source,[F]),lookbehind:!0,greedy:!0,inside:Z(F,T)},{pattern:n(/(^|[^@\\])\$"(?:\\.|\{\{|<<0>>|[^\\"{])*"/.source,[U]),lookbehind:!0,greedy:!0,inside:Z(U,N)}],char:{pattern:RegExp($),greedy:!0}}),e.languages.dotnet=e.languages.cs=e.languages.csharp}(e)}e.exports=s,s.displayName="csharp",s.aliases=["dotnet","cs"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4652.9a5d2242.chunk.js b/ydb/core/viewer/monitoring/static/js/4652.9a5d2242.chunk.js deleted file mode 100644 index 72f160b45919..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4652.9a5d2242.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4652],{84652:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"lo",weekdays:"\u0ead\u0eb2\u0e97\u0eb4\u0e94_\u0e88\u0eb1\u0e99_\u0ead\u0eb1\u0e87\u0e84\u0eb2\u0e99_\u0e9e\u0eb8\u0e94_\u0e9e\u0eb0\u0eab\u0eb1\u0e94_\u0eaa\u0eb8\u0e81_\u0ec0\u0eaa\u0ebb\u0eb2".split("_"),months:"\u0ea1\u0eb1\u0e87\u0e81\u0ead\u0e99_\u0e81\u0eb8\u0ea1\u0e9e\u0eb2_\u0ea1\u0eb5\u0e99\u0eb2_\u0ec0\u0ea1\u0eaa\u0eb2_\u0e9e\u0eb6\u0e94\u0eaa\u0eb0\u0e9e\u0eb2_\u0ea1\u0eb4\u0e96\u0eb8\u0e99\u0eb2_\u0e81\u0ecd\u0ea5\u0eb0\u0e81\u0ebb\u0e94_\u0eaa\u0eb4\u0e87\u0eab\u0eb2_\u0e81\u0eb1\u0e99\u0e8d\u0eb2_\u0e95\u0eb8\u0ea5\u0eb2_\u0e9e\u0eb0\u0e88\u0eb4\u0e81_\u0e97\u0eb1\u0e99\u0ea7\u0eb2".split("_"),weekdaysShort:"\u0e97\u0eb4\u0e94_\u0e88\u0eb1\u0e99_\u0ead\u0eb1\u0e87\u0e84\u0eb2\u0e99_\u0e9e\u0eb8\u0e94_\u0e9e\u0eb0\u0eab\u0eb1\u0e94_\u0eaa\u0eb8\u0e81_\u0ec0\u0eaa\u0ebb\u0eb2".split("_"),monthsShort:"\u0ea1\u0eb1\u0e87\u0e81\u0ead\u0e99_\u0e81\u0eb8\u0ea1\u0e9e\u0eb2_\u0ea1\u0eb5\u0e99\u0eb2_\u0ec0\u0ea1\u0eaa\u0eb2_\u0e9e\u0eb6\u0e94\u0eaa\u0eb0\u0e9e\u0eb2_\u0ea1\u0eb4\u0e96\u0eb8\u0e99\u0eb2_\u0e81\u0ecd\u0ea5\u0eb0\u0e81\u0ebb\u0e94_\u0eaa\u0eb4\u0e87\u0eab\u0eb2_\u0e81\u0eb1\u0e99\u0e8d\u0eb2_\u0e95\u0eb8\u0ea5\u0eb2_\u0e9e\u0eb0\u0e88\u0eb4\u0e81_\u0e97\u0eb1\u0e99\u0ea7\u0eb2".split("_"),weekdaysMin:"\u0e97_\u0e88_\u0ead\u0e84_\u0e9e_\u0e9e\u0eab_\u0eaa\u0e81_\u0eaa".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"\u0ea7\u0eb1\u0e99dddd D MMMM YYYY HH:mm"},relativeTime:{future:"\u0ead\u0eb5\u0e81 %s",past:"%s\u0e9c\u0ec8\u0eb2\u0e99\u0ea1\u0eb2",s:"\u0e9a\u0ecd\u0ec8\u0ec0\u0e97\u0ebb\u0ec8\u0eb2\u0ec3\u0e94\u0ea7\u0eb4\u0e99\u0eb2\u0e97\u0eb5",m:"1 \u0e99\u0eb2\u0e97\u0eb5",mm:"%d \u0e99\u0eb2\u0e97\u0eb5",h:"1 \u0e8a\u0ebb\u0ec8\u0ea7\u0ec2\u0ea1\u0e87",hh:"%d \u0e8a\u0ebb\u0ec8\u0ea7\u0ec2\u0ea1\u0e87",d:"1 \u0ea1\u0eb7\u0ec9",dd:"%d \u0ea1\u0eb7\u0ec9",M:"1 \u0ec0\u0e94\u0eb7\u0ead\u0e99",MM:"%d \u0ec0\u0e94\u0eb7\u0ead\u0e99",y:"1 \u0e9b\u0eb5",yy:"%d \u0e9b\u0eb5"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/46541.3c0665eb.chunk.js b/ydb/core/viewer/monitoring/static/js/46541.3c0665eb.chunk.js new file mode 100644 index 000000000000..215476df1af3 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/46541.3c0665eb.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[46541],{46541:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"km",weekdays:"\u17a2\u17b6\u1791\u17b7\u178f\u17d2\u1799_\u1785\u17d0\u1793\u17d2\u1791_\u17a2\u1784\u17d2\u1782\u17b6\u179a_\u1796\u17bb\u1792_\u1796\u17d2\u179a\u17a0\u179f\u17d2\u1794\u178f\u17b7\u17cd_\u179f\u17bb\u1780\u17d2\u179a_\u179f\u17c5\u179a\u17cd".split("_"),months:"\u1798\u1780\u179a\u17b6_\u1780\u17bb\u1798\u17d2\u1797\u17c8_\u1798\u17b8\u1793\u17b6_\u1798\u17c1\u179f\u17b6_\u17a7\u179f\u1797\u17b6_\u1798\u17b7\u1790\u17bb\u1793\u17b6_\u1780\u1780\u17d2\u1780\u178a\u17b6_\u179f\u17b8\u17a0\u17b6_\u1780\u1789\u17d2\u1789\u17b6_\u178f\u17bb\u179b\u17b6_\u179c\u17b7\u1785\u17d2\u1786\u17b7\u1780\u17b6_\u1792\u17d2\u1793\u17bc".split("_"),weekStart:1,weekdaysShort:"\u17a2\u17b6_\u1785_\u17a2_\u1796_\u1796\u17d2\u179a_\u179f\u17bb_\u179f".split("_"),monthsShort:"\u1798\u1780\u179a\u17b6_\u1780\u17bb\u1798\u17d2\u1797\u17c8_\u1798\u17b8\u1793\u17b6_\u1798\u17c1\u179f\u17b6_\u17a7\u179f\u1797\u17b6_\u1798\u17b7\u1790\u17bb\u1793\u17b6_\u1780\u1780\u17d2\u1780\u178a\u17b6_\u179f\u17b8\u17a0\u17b6_\u1780\u1789\u17d2\u1789\u17b6_\u178f\u17bb\u179b\u17b6_\u179c\u17b7\u1785\u17d2\u1786\u17b7\u1780\u17b6_\u1792\u17d2\u1793\u17bc".split("_"),weekdaysMin:"\u17a2\u17b6_\u1785_\u17a2_\u1796_\u1796\u17d2\u179a_\u179f\u17bb_\u179f".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s\u1791\u17c0\u178f",past:"%s\u1798\u17bb\u1793",s:"\u1794\u17c9\u17bb\u1793\u17d2\u1798\u17b6\u1793\u179c\u17b7\u1793\u17b6\u1791\u17b8",m:"\u1798\u17bd\u1799\u1793\u17b6\u1791\u17b8",mm:"%d \u1793\u17b6\u1791\u17b8",h:"\u1798\u17bd\u1799\u1798\u17c9\u17c4\u1784",hh:"%d \u1798\u17c9\u17c4\u1784",d:"\u1798\u17bd\u1799\u1790\u17d2\u1784\u17c3",dd:"%d \u1790\u17d2\u1784\u17c3",M:"\u1798\u17bd\u1799\u1781\u17c2",MM:"%d \u1781\u17c2",y:"\u1798\u17bd\u1799\u1786\u17d2\u1793\u17b6\u17c6",yy:"%d \u1786\u17d2\u1793\u17b6\u17c6"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4662.1c10232d.chunk.js b/ydb/core/viewer/monitoring/static/js/4662.1c10232d.chunk.js deleted file mode 100644 index 3c41698a4343..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4662.1c10232d.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4662.1c10232d.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4662],{24662:(E,S,e)=>{e.r(S),e.d(S,{conf:()=>T,language:()=>R});var T={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},R={defaultToken:"",tokenPostfix:".redis",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["APPEND","AUTH","BGREWRITEAOF","BGSAVE","BITCOUNT","BITFIELD","BITOP","BITPOS","BLPOP","BRPOP","BRPOPLPUSH","CLIENT","KILL","LIST","GETNAME","PAUSE","REPLY","SETNAME","CLUSTER","ADDSLOTS","COUNT-FAILURE-REPORTS","COUNTKEYSINSLOT","DELSLOTS","FAILOVER","FORGET","GETKEYSINSLOT","INFO","KEYSLOT","MEET","NODES","REPLICATE","RESET","SAVECONFIG","SET-CONFIG-EPOCH","SETSLOT","SLAVES","SLOTS","COMMAND","COUNT","GETKEYS","CONFIG","GET","REWRITE","SET","RESETSTAT","DBSIZE","DEBUG","OBJECT","SEGFAULT","DECR","DECRBY","DEL","DISCARD","DUMP","ECHO","EVAL","EVALSHA","EXEC","EXISTS","EXPIRE","EXPIREAT","FLUSHALL","FLUSHDB","GEOADD","GEOHASH","GEOPOS","GEODIST","GEORADIUS","GEORADIUSBYMEMBER","GETBIT","GETRANGE","GETSET","HDEL","HEXISTS","HGET","HGETALL","HINCRBY","HINCRBYFLOAT","HKEYS","HLEN","HMGET","HMSET","HSET","HSETNX","HSTRLEN","HVALS","INCR","INCRBY","INCRBYFLOAT","KEYS","LASTSAVE","LINDEX","LINSERT","LLEN","LPOP","LPUSH","LPUSHX","LRANGE","LREM","LSET","LTRIM","MGET","MIGRATE","MONITOR","MOVE","MSET","MSETNX","MULTI","PERSIST","PEXPIRE","PEXPIREAT","PFADD","PFCOUNT","PFMERGE","PING","PSETEX","PSUBSCRIBE","PUBSUB","PTTL","PUBLISH","PUNSUBSCRIBE","QUIT","RANDOMKEY","READONLY","READWRITE","RENAME","RENAMENX","RESTORE","ROLE","RPOP","RPOPLPUSH","RPUSH","RPUSHX","SADD","SAVE","SCARD","SCRIPT","FLUSH","LOAD","SDIFF","SDIFFSTORE","SELECT","SETBIT","SETEX","SETNX","SETRANGE","SHUTDOWN","SINTER","SINTERSTORE","SISMEMBER","SLAVEOF","SLOWLOG","SMEMBERS","SMOVE","SORT","SPOP","SRANDMEMBER","SREM","STRLEN","SUBSCRIBE","SUNION","SUNIONSTORE","SWAPDB","SYNC","TIME","TOUCH","TTL","TYPE","UNSUBSCRIBE","UNLINK","UNWATCH","WAIT","WATCH","ZADD","ZCARD","ZCOUNT","ZINCRBY","ZINTERSTORE","ZLEXCOUNT","ZRANGE","ZRANGEBYLEX","ZREVRANGEBYLEX","ZRANGEBYSCORE","ZRANK","ZREM","ZREMRANGEBYLEX","ZREMRANGEBYRANK","ZREMRANGEBYSCORE","ZREVRANGE","ZREVRANGEBYSCORE","ZREVRANK","ZSCORE","ZUNIONSTORE","SCAN","SSCAN","HSCAN","ZSCAN"],operators:[],builtinFunctions:[],builtinVariables:[],pseudoColumns:[],tokenizer:{root:[{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@keywords":"keyword","@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}],[/"/,{token:"string.double",next:"@stringDouble"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],stringDouble:[[/[^"]+/,"string.double"],[/""/,"string.double"],[/"/,{token:"string.double",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4664.972299e2.chunk.js b/ydb/core/viewer/monitoring/static/js/4664.972299e2.chunk.js new file mode 100644 index 000000000000..dfde6ca6993f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/4664.972299e2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4664],{4664:(e,n,t)=>{t.d(n,{default:()=>s});var a=t(89343);const s=t.n(a)()},89343:e=>{function n(e){e.languages.c=e.languages.extend("clike",{comment:{pattern:/\/\/(?:[^\r\n\\]|\\(?:\r\n?|\n|(?![\r\n])))*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"/,greedy:!0},"class-name":{pattern:/(\b(?:enum|struct)\s+(?:__attribute__\s*\(\([\s\S]*?\)\)\s*)?)\w+|\b[a-z]\w*_t\b/,lookbehind:!0},keyword:/\b(?:_Alignas|_Alignof|_Atomic|_Bool|_Complex|_Generic|_Imaginary|_Noreturn|_Static_assert|_Thread_local|__attribute__|asm|auto|break|case|char|const|continue|default|do|double|else|enum|extern|float|for|goto|if|inline|int|long|register|return|short|signed|sizeof|static|struct|switch|typedef|typeof|union|unsigned|void|volatile|while)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,number:/(?:\b0x(?:[\da-f]+(?:\.[\da-f]*)?|\.[\da-f]+)(?:p[+-]?\d+)?|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ful]{0,4}/i,operator:/>>=?|<<=?|->|([-+&|:])\1|[?:~]|[-+*/%&|^!=<>]=?/}),e.languages.insertBefore("c","string",{char:{pattern:/'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n]){0,32}'/,greedy:!0}}),e.languages.insertBefore("c","string",{macro:{pattern:/(^[\t ]*)#\s*[a-z](?:[^\r\n\\/]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|\\(?:\r\n|[\s\S]))*/im,lookbehind:!0,greedy:!0,alias:"property",inside:{string:[{pattern:/^(#\s*include\s*)<[^>]+>/,lookbehind:!0},e.languages.c.string],char:e.languages.c.char,comment:e.languages.c.comment,"macro-name":[{pattern:/(^#\s*define\s+)\w+\b(?!\()/i,lookbehind:!0},{pattern:/(^#\s*define\s+)\w+\b(?=\()/i,lookbehind:!0,alias:"function"}],directive:{pattern:/^(#\s*)[a-z]+/,lookbehind:!0,alias:"keyword"},"directive-hash":/^#/,punctuation:/##|\\(?=[\r\n])/,expression:{pattern:/\S[\s\S]*/,inside:e.languages.c}}}}),e.languages.insertBefore("c","function",{constant:/\b(?:EOF|NULL|SEEK_CUR|SEEK_END|SEEK_SET|__DATE__|__FILE__|__LINE__|__TIMESTAMP__|__TIME__|__func__|stderr|stdin|stdout)\b/}),delete e.languages.c.boolean}e.exports=n,n.displayName="c",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4678.4e2f4af4.chunk.js b/ydb/core/viewer/monitoring/static/js/4678.4e2f4af4.chunk.js deleted file mode 100644 index 7ebde4af5f05..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4678.4e2f4af4.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4678.4e2f4af4.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4678],{54678:(e,n,s)=>{s.r(n),s.d(n,{conf:()=>i,language:()=>o});var i={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},o={defaultToken:"",tokenPostfix:".ini",escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[[/^\[[^\]]*\]/,"metatag"],[/(^\w+)(\s*)(\=)/,["key","","delimiter"]],{include:"@whitespace"},[/\d+/,"number"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/"/,"string",'@string."'],[/'/,"string","@string.'"]],whitespace:[[/[ \t\r\n]+/,""],[/^\s*[#;].*$/,"comment"]],string:[[/[^\\"']+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/["']/,{cases:{"$#==$S2":{token:"string",next:"@pop"},"@default":"string"}}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47.54dd12ac.chunk.js b/ydb/core/viewer/monitoring/static/js/47.54dd12ac.chunk.js deleted file mode 100644 index 999f39d3ab43..000000000000 --- a/ydb/core/viewer/monitoring/static/js/47.54dd12ac.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47],{40047:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"kk",weekdays:"\u0436\u0435\u043a\u0441\u0435\u043d\u0431\u0456_\u0434\u04af\u0439\u0441\u0435\u043d\u0431\u0456_\u0441\u0435\u0439\u0441\u0435\u043d\u0431\u0456_\u0441\u04d9\u0440\u0441\u0435\u043d\u0431\u0456_\u0431\u0435\u0439\u0441\u0435\u043d\u0431\u0456_\u0436\u04b1\u043c\u0430_\u0441\u0435\u043d\u0431\u0456".split("_"),weekdaysShort:"\u0436\u0435\u043a_\u0434\u04af\u0439_\u0441\u0435\u0439_\u0441\u04d9\u0440_\u0431\u0435\u0439_\u0436\u04b1\u043c_\u0441\u0435\u043d".split("_"),weekdaysMin:"\u0436\u043a_\u0434\u0439_\u0441\u0439_\u0441\u0440_\u0431\u0439_\u0436\u043c_\u0441\u043d".split("_"),months:"\u049b\u0430\u04a3\u0442\u0430\u0440_\u0430\u049b\u043f\u0430\u043d_\u043d\u0430\u0443\u0440\u044b\u0437_\u0441\u04d9\u0443\u0456\u0440_\u043c\u0430\u043c\u044b\u0440_\u043c\u0430\u0443\u0441\u044b\u043c_\u0448\u0456\u043b\u0434\u0435_\u0442\u0430\u043c\u044b\u0437_\u049b\u044b\u0440\u043a\u04af\u0439\u0435\u043a_\u049b\u0430\u0437\u0430\u043d_\u049b\u0430\u0440\u0430\u0448\u0430_\u0436\u0435\u043b\u0442\u043e\u049b\u0441\u0430\u043d".split("_"),monthsShort:"\u049b\u0430\u04a3_\u0430\u049b\u043f_\u043d\u0430\u0443_\u0441\u04d9\u0443_\u043c\u0430\u043c_\u043c\u0430\u0443_\u0448\u0456\u043b_\u0442\u0430\u043c_\u049b\u044b\u0440_\u049b\u0430\u0437_\u049b\u0430\u0440_\u0436\u0435\u043b".split("_"),weekStart:1,relativeTime:{future:"%s \u0456\u0448\u0456\u043d\u0434\u0435",past:"%s \u0431\u04b1\u0440\u044b\u043d",s:"\u0431\u0456\u0440\u043d\u0435\u0448\u0435 \u0441\u0435\u043a\u0443\u043d\u0434",m:"\u0431\u0456\u0440 \u043c\u0438\u043d\u0443\u0442",mm:"%d \u043c\u0438\u043d\u0443\u0442",h:"\u0431\u0456\u0440 \u0441\u0430\u0493\u0430\u0442",hh:"%d \u0441\u0430\u0493\u0430\u0442",d:"\u0431\u0456\u0440 \u043a\u04af\u043d",dd:"%d \u043a\u04af\u043d",M:"\u0431\u0456\u0440 \u0430\u0439",MM:"%d \u0430\u0439",y:"\u0431\u0456\u0440 \u0436\u044b\u043b",yy:"%d \u0436\u044b\u043b"},ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47108.d6adff77.chunk.js b/ydb/core/viewer/monitoring/static/js/47108.d6adff77.chunk.js new file mode 100644 index 000000000000..c79e12104876 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47108.d6adff77.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47108],{47108:(e,t,a)=>{a.d(t,{default:()=>n});var s=a(49973);const n=a.n(s)()},49973:e=>{function t(e){e.languages.properties={comment:/^[ \t]*[#!].*$/m,"attr-value":{pattern:/(^[ \t]*(?:\\(?:\r\n|[\s\S])|[^\\\s:=])+(?: *[=:] *(?! )| ))(?:\\(?:\r\n|[\s\S])|[^\\\r\n])+/m,lookbehind:!0},"attr-name":/^[ \t]*(?:\\(?:\r\n|[\s\S])|[^\\\s:=])+(?= *[=:]| )/m,punctuation:/[=:]/}}e.exports=t,t.displayName="properties",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47153.2c051af0.chunk.js b/ydb/core/viewer/monitoring/static/js/47153.2c051af0.chunk.js new file mode 100644 index 000000000000..44393d3703e2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47153.2c051af0.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47153],{22456:e=>{function t(e){e.languages.unrealscript={comment:/\/\/.*|\/\*[\s\S]*?\*\//,string:{pattern:/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0},category:{pattern:/(\b(?:(?:autoexpand|hide|show)categories|var)\s*\()[^()]+(?=\))/,lookbehind:!0,greedy:!0,alias:"property"},metadata:{pattern:/(\w\s*)<\s*\w+\s*=[^<>|=\r\n]+(?:\|\s*\w+\s*=[^<>|=\r\n]+)*>/,lookbehind:!0,greedy:!0,inside:{property:/\b\w+(?=\s*=)/,operator:/=/,punctuation:/[<>|]/}},macro:{pattern:/`\w+/,alias:"property"},"class-name":{pattern:/(\b(?:class|enum|extends|interface|state(?:\(\))?|struct|within)\s+)\w+/,lookbehind:!0},keyword:/\b(?:abstract|actor|array|auto|autoexpandcategories|bool|break|byte|case|class|classgroup|client|coerce|collapsecategories|config|const|continue|default|defaultproperties|delegate|dependson|deprecated|do|dontcollapsecategories|editconst|editinlinenew|else|enum|event|exec|export|extends|final|float|for|forcescriptorder|foreach|function|goto|guid|hidecategories|hidedropdown|if|ignores|implements|inherits|input|int|interface|iterator|latent|local|material|name|native|nativereplication|noexport|nontransient|noteditinlinenew|notplaceable|operator|optional|out|pawn|perobjectconfig|perobjectlocalized|placeable|postoperator|preoperator|private|protected|reliable|replication|return|server|showcategories|simulated|singular|state|static|string|struct|structdefault|structdefaultproperties|switch|texture|transient|travel|unreliable|until|var|vector|while|within)\b/,function:/\b[a-z_]\w*(?=\s*\()/i,boolean:/\b(?:false|true)\b/,number:/\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?/i,operator:/>>|<<|--|\+\+|\*\*|[-+*/~!=<>$@]=?|&&?|\|\|?|\^\^?|[?:%]|\b(?:ClockwiseFrom|Cross|Dot)\b/,punctuation:/[()[\]{};,.]/},e.languages.uc=e.languages.uscript=e.languages.unrealscript}e.exports=t,t.displayName="unrealscript",t.aliases=["uc","uscript"]},47153:(e,t,a)=>{a.d(t,{default:()=>n});var r=a(22456);const n=a.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47472.10032073.chunk.js b/ydb/core/viewer/monitoring/static/js/47472.10032073.chunk.js new file mode 100644 index 000000000000..04fd2ec4c24d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47472.10032073.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47472],{47472:(a,e,b)=>{b.d(e,{default:()=>l});var d=b(98265);const l=b.n(d)()},98265:a=>{function e(a){!function(a){a.languages.llvm={comment:/;.*/,string:{pattern:/"[^"]*"/,greedy:!0},boolean:/\b(?:false|true)\b/,variable:/[%@!#](?:(?!\d)(?:[-$.\w]|\\[a-f\d]{2})+|\d+)/i,label:/(?!\d)(?:[-$.\w]|\\[a-f\d]{2})+:/i,type:{pattern:/\b(?:double|float|fp128|half|i[1-9]\d*|label|metadata|ppc_fp128|token|void|x86_fp80|x86_mmx)\b/,alias:"class-name"},keyword:/\b[a-z_][a-z_0-9]*\b/,number:/[+-]?\b\d+(?:\.\d+)?(?:[eE][+-]?\d+)?\b|\b0x[\dA-Fa-f]+\b|\b0xK[\dA-Fa-f]{20}\b|\b0x[ML][\dA-Fa-f]{32}\b|\b0xH[\dA-Fa-f]{4}\b/,punctuation:/[{}[\];(),.!*=<>]/}}(a)}a.exports=e,e.displayName="llvm",e.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47614.68df3ac9.chunk.js b/ydb/core/viewer/monitoring/static/js/47614.68df3ac9.chunk.js new file mode 100644 index 000000000000..30ef12c9bd0d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47614.68df3ac9.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[28868,47614],{28868:(e,o,s)=>{"use strict";s.r(o)},47614:(e,o,s)=>{var r={"./editorBaseApi":73848,"./editorBaseApi.js":73848,"./editorSimpleWorker":16545,"./editorSimpleWorker.js":16545,"./editorWorker":10920,"./editorWorker.js":10920,"./editorWorkerHost":80718,"./editorWorkerHost.js":80718,"./findSectionHeaders":56691,"./findSectionHeaders.js":56691,"./getIconClasses":53068,"./getIconClasses.js":53068,"./languageFeatureDebounce":32500,"./languageFeatureDebounce.js":32500,"./languageFeatures":56942,"./languageFeatures.js":56942,"./languageFeaturesService":76007,"./languageFeaturesService.js":76007,"./languageService":17890,"./languageService.js":17890,"./languagesAssociations":99908,"./languagesAssociations.js":99908,"./languagesRegistry":69259,"./languagesRegistry.js":69259,"./markerDecorations":37550,"./markerDecorations.js":37550,"./markerDecorationsService":30707,"./markerDecorationsService.js":30707,"./model":23750,"./model.js":23750,"./modelService":16363,"./modelService.js":16363,"./resolverService":18938,"./resolverService.js":18938,"./semanticTokensDto":98232,"./semanticTokensDto.js":98232,"./semanticTokensProviderStyling":45538,"./semanticTokensProviderStyling.js":45538,"./semanticTokensStyling":74243,"./semanticTokensStyling.js":74243,"./semanticTokensStylingService":27004,"./semanticTokensStylingService.js":27004,"./textModelSync/textModelSync.impl":47443,"./textModelSync/textModelSync.impl.js":47443,"./textModelSync/textModelSync.protocol":28868,"./textModelSync/textModelSync.protocol.js":28868,"./textResourceConfiguration":90360,"./textResourceConfiguration.js":90360,"./treeSitterParserService":44432,"./treeSitterParserService.js":44432,"./treeViewsDnd":36723,"./treeViewsDnd.js":36723,"./treeViewsDndService":29100,"./treeViewsDndService.js":29100,"./unicodeTextModelHighlighter":74855,"./unicodeTextModelHighlighter.js":74855,"monaco-editor/esm/vs/editor/common/services/editorBaseApi":73848,"monaco-editor/esm/vs/editor/common/services/editorBaseApi.js":73848,"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker":16545,"monaco-editor/esm/vs/editor/common/services/editorSimpleWorker.js":16545,"monaco-editor/esm/vs/editor/common/services/editorWorker":10920,"monaco-editor/esm/vs/editor/common/services/editorWorker.js":10920,"monaco-editor/esm/vs/editor/common/services/editorWorkerHost":80718,"monaco-editor/esm/vs/editor/common/services/editorWorkerHost.js":80718,"monaco-editor/esm/vs/editor/common/services/findSectionHeaders":56691,"monaco-editor/esm/vs/editor/common/services/findSectionHeaders.js":56691,"monaco-editor/esm/vs/editor/common/services/getIconClasses":53068,"monaco-editor/esm/vs/editor/common/services/getIconClasses.js":53068,"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce":32500,"monaco-editor/esm/vs/editor/common/services/languageFeatureDebounce.js":32500,"monaco-editor/esm/vs/editor/common/services/languageFeatures":56942,"monaco-editor/esm/vs/editor/common/services/languageFeatures.js":56942,"monaco-editor/esm/vs/editor/common/services/languageFeaturesService":76007,"monaco-editor/esm/vs/editor/common/services/languageFeaturesService.js":76007,"monaco-editor/esm/vs/editor/common/services/languageService":17890,"monaco-editor/esm/vs/editor/common/services/languageService.js":17890,"monaco-editor/esm/vs/editor/common/services/languagesAssociations":99908,"monaco-editor/esm/vs/editor/common/services/languagesAssociations.js":99908,"monaco-editor/esm/vs/editor/common/services/languagesRegistry":69259,"monaco-editor/esm/vs/editor/common/services/languagesRegistry.js":69259,"monaco-editor/esm/vs/editor/common/services/markerDecorations":37550,"monaco-editor/esm/vs/editor/common/services/markerDecorations.js":37550,"monaco-editor/esm/vs/editor/common/services/markerDecorationsService":30707,"monaco-editor/esm/vs/editor/common/services/markerDecorationsService.js":30707,"monaco-editor/esm/vs/editor/common/services/model":23750,"monaco-editor/esm/vs/editor/common/services/model.js":23750,"monaco-editor/esm/vs/editor/common/services/modelService":16363,"monaco-editor/esm/vs/editor/common/services/modelService.js":16363,"monaco-editor/esm/vs/editor/common/services/resolverService":18938,"monaco-editor/esm/vs/editor/common/services/resolverService.js":18938,"monaco-editor/esm/vs/editor/common/services/semanticTokensDto":98232,"monaco-editor/esm/vs/editor/common/services/semanticTokensDto.js":98232,"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling":45538,"monaco-editor/esm/vs/editor/common/services/semanticTokensProviderStyling.js":45538,"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling":74243,"monaco-editor/esm/vs/editor/common/services/semanticTokensStyling.js":74243,"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService":27004,"monaco-editor/esm/vs/editor/common/services/semanticTokensStylingService.js":27004,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl":47443,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.impl.js":47443,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol":28868,"monaco-editor/esm/vs/editor/common/services/textModelSync/textModelSync.protocol.js":28868,"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration":90360,"monaco-editor/esm/vs/editor/common/services/textResourceConfiguration.js":90360,"monaco-editor/esm/vs/editor/common/services/treeSitterParserService":44432,"monaco-editor/esm/vs/editor/common/services/treeSitterParserService.js":44432,"monaco-editor/esm/vs/editor/common/services/treeViewsDnd":36723,"monaco-editor/esm/vs/editor/common/services/treeViewsDnd.js":36723,"monaco-editor/esm/vs/editor/common/services/treeViewsDndService":29100,"monaco-editor/esm/vs/editor/common/services/treeViewsDndService.js":29100,"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter":74855,"monaco-editor/esm/vs/editor/common/services/unicodeTextModelHighlighter.js":74855};function i(e){var o=t(e);return s(o)}function t(e){if(!s.o(r,e)){var o=new Error("Cannot find module '"+e+"'");throw o.code="MODULE_NOT_FOUND",o}return r[e]}i.keys=function(){return Object.keys(r)},i.resolve=t,e.exports=i,i.id=47614}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47660.d58e412b.chunk.js b/ydb/core/viewer/monitoring/static/js/47660.d58e412b.chunk.js new file mode 100644 index 000000000000..f75e15d2f8fd --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47660.d58e412b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47660],{47660:(e,a,t)=>{t.d(a,{default:()=>r});var n=t(92779);const r=t.n(n)()},51572:e=>{function a(e){!function(e){function a(e,a){return"___"+e.toUpperCase()+a+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,n,r,l){if(t.language===n){var i=t.tokenStack=[];t.code=t.code.replace(r,(function(e){if("function"===typeof l&&!l(e))return e;for(var r,o=i.length;-1!==t.code.indexOf(r=a(n,o));)++o;return i[o]=e,r})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,n){if(t.language===n&&t.tokenStack){t.grammar=e.languages[n];var r=0,l=Object.keys(t.tokenStack);!function i(o){for(var s=0;s=l.length);s++){var p=o[s];if("string"===typeof p||p.content&&"string"===typeof p.content){var u=l[r],c=t.tokenStack[u],d="string"===typeof p?p:p.content,g=a(n,u),b=d.indexOf(g);if(b>-1){++r;var m=d.substring(0,b),f=new e.Token(n,e.tokenize(c,t.grammar),"language-"+n,c),k=d.substring(b+g.length),h=[];m&&h.push.apply(h,i([m])),h.push(f),k&&h.push.apply(h,i([k])),"string"===typeof p?o.splice.apply(o,[s,1].concat(h)):p.content=h}}else p.content&&i(p.content)}return o}(t.tokens)}}}})}(e)}e.exports=a,a.displayName="markupTemplating",a.aliases=[]},92779:(e,a,t)=>{var n=t(51572);function r(e){e.register(n),function(e){var a=/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,t=/\b\d+(?:\.\d+)?(?:[eE][+-]?\d+)?\b|\b0x[\dA-F]+\b/;e.languages.soy={comment:[/\/\*[\s\S]*?\*\//,{pattern:/(\s)\/\/.*/,lookbehind:!0,greedy:!0}],"command-arg":{pattern:/(\{+\/?\s*(?:alias|call|delcall|delpackage|deltemplate|namespace|template)\s+)\.?[\w.]+/,lookbehind:!0,alias:"string",inside:{punctuation:/\./}},parameter:{pattern:/(\{+\/?\s*@?param\??\s+)\.?[\w.]+/,lookbehind:!0,alias:"variable"},keyword:[{pattern:/(\{+\/?[^\S\r\n]*)(?:\\[nrt]|alias|call|case|css|default|delcall|delpackage|deltemplate|else(?:if)?|fallbackmsg|for(?:each)?|if(?:empty)?|lb|let|literal|msg|namespace|nil|@?param\??|rb|sp|switch|template|xid)/,lookbehind:!0},/\b(?:any|as|attributes|bool|css|float|html|in|int|js|list|map|null|number|string|uri)\b/],delimiter:{pattern:/^\{+\/?|\/?\}+$/,alias:"punctuation"},property:/\w+(?==)/,variable:{pattern:/\$[^\W\d]\w*(?:\??(?:\.\w+|\[[^\]]+\]))*/,inside:{string:{pattern:a,greedy:!0},number:t,punctuation:/[\[\].?]/}},string:{pattern:a,greedy:!0},function:[/\w+(?=\()/,{pattern:/(\|[^\S\r\n]*)\w+/,lookbehind:!0}],boolean:/\b(?:false|true)\b/,number:t,operator:/\?:?|<=?|>=?|==?|!=|[+*/%-]|\b(?:and|not|or)\b/,punctuation:/[{}()\[\]|.,:]/},e.hooks.add("before-tokenize",(function(a){var t=!1;e.languages["markup-templating"].buildPlaceholders(a,"soy",/\{\{.+?\}\}|\{.+?\}|\s\/\/.*|\/\*[\s\S]*?\*\//g,(function(e){return"{/literal}"===e&&(t=!1),!t&&("{literal}"===e&&(t=!0),!0)}))})),e.hooks.add("after-tokenize",(function(a){e.languages["markup-templating"].tokenizePlaceholders(a,"soy")}))}(e)}e.exports=r,r.displayName="soy",r.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/47692.c0ce8e67.chunk.js b/ydb/core/viewer/monitoring/static/js/47692.c0ce8e67.chunk.js new file mode 100644 index 000000000000..565eb81b0d29 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47692.c0ce8e67.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 47692.c0ce8e67.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47692],{47692:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>s,language:()=>o});var s={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*//\\s*#region\\b|^\\s*\\(\\*\\s*#region(.*)\\*\\)"),end:new RegExp("^\\s*//\\s*#endregion\\b|^\\s*\\(\\*\\s*#endregion\\s*\\*\\)")}}},o={defaultToken:"",tokenPostfix:".fs",keywords:["abstract","and","atomic","as","assert","asr","base","begin","break","checked","component","const","constraint","constructor","continue","class","default","delegate","do","done","downcast","downto","elif","else","end","exception","eager","event","external","extern","false","finally","for","fun","function","fixed","functor","global","if","in","include","inherit","inline","interface","internal","land","lor","lsl","lsr","lxor","lazy","let","match","member","mod","module","mutable","namespace","method","mixin","new","not","null","of","open","or","object","override","private","parallel","process","protected","pure","public","rec","return","static","sealed","struct","sig","then","to","true","tailcall","trait","try","type","upcast","use","val","void","virtual","volatile","when","while","with","yield"],symbols:/[=>\]/,"annotation"],[/^#(if|else|endif)/,"keyword"],[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,"delimiter"],[/\d*\d+[eE]([\-+]?\d+)?(@floatsuffix)/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?(@floatsuffix)/,"number.float"],[/0x[0-9a-fA-F]+LF/,"number.float"],[/0x[0-9a-fA-F]+(@integersuffix)/,"number.hex"],[/0b[0-1]+(@integersuffix)/,"number.bin"],[/\d+(@integersuffix)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"""/,"string",'@string."""'],[/"/,"string",'@string."'],[/\@"/,{token:"string.quote",next:"@litstring"}],[/'[^\\']'B?/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\(\*(?!\))/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^*(]+/,"comment"],[/\*\)/,"comment","@pop"],[/\*/,"comment"],[/\(\*\)/,"comment"],[/\(/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/("""|"B?)/,{cases:{"$#==$S2":{token:"string",next:"@pop"},"@default":"string"}}]],litstring:[[/[^"]+/,"string"],[/""/,"string.escape"],[/"/,{token:"string.quote",next:"@pop"}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4662.1c10232d.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/47692.c0ce8e67.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/4662.1c10232d.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/47692.c0ce8e67.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/47878.706bd425.chunk.js b/ydb/core/viewer/monitoring/static/js/47878.706bd425.chunk.js new file mode 100644 index 000000000000..535d20c34f3e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/47878.706bd425.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[47878],{47878:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e),a={s:"ein paar Sekunden",m:["eine Minute","einer Minute"],mm:"%d Minuten",h:["eine Stunde","einer Stunde"],hh:"%d Stunden",d:["ein Tag","einem Tag"],dd:["%d Tage","%d Tagen"],M:["ein Monat","einem Monat"],MM:["%d Monate","%d Monaten"],y:["ein Jahr","einem Jahr"],yy:["%d Jahre","%d Jahren"]};function i(e,n,t){var i=a[t];return Array.isArray(i)&&(i=i[n?0:1]),i.replace("%d",e)}var r={name:"de",weekdays:"Sonntag_Montag_Dienstag_Mittwoch_Donnerstag_Freitag_Samstag".split("_"),weekdaysShort:"So._Mo._Di._Mi._Do._Fr._Sa.".split("_"),weekdaysMin:"So_Mo_Di_Mi_Do_Fr_Sa".split("_"),months:"Januar_Februar_M\xe4rz_April_Mai_Juni_Juli_August_September_Oktober_November_Dezember".split("_"),monthsShort:"Jan._Feb._M\xe4rz_Apr._Mai_Juni_Juli_Aug._Sept._Okt._Nov._Dez.".split("_"),ordinal:function(e){return e+"."},weekStart:1,yearStart:4,formats:{LTS:"HH:mm:ss",LT:"HH:mm",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY HH:mm",LLLL:"dddd, D. MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"vor %s",s:i,m:i,mm:i,h:i,hh:i,d:i,dd:i,M:i,MM:i,y:i,yy:i}};return t.default.locale(r,null,!0),r}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/48008.f90295f8.chunk.js b/ydb/core/viewer/monitoring/static/js/48008.f90295f8.chunk.js new file mode 100644 index 000000000000..7f6e10ffd1dc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/48008.f90295f8.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[48008],{48008:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ne",weekdays:"\u0906\u0907\u0924\u092c\u093e\u0930_\u0938\u094b\u092e\u092c\u093e\u0930_\u092e\u0919\u094d\u0917\u0932\u092c\u093e\u0930_\u092c\u0941\u0927\u092c\u093e\u0930_\u092c\u093f\u0939\u093f\u092c\u093e\u0930_\u0936\u0941\u0915\u094d\u0930\u092c\u093e\u0930_\u0936\u0928\u093f\u092c\u093e\u0930".split("_"),weekdaysShort:"\u0906\u0907\u0924._\u0938\u094b\u092e._\u092e\u0919\u094d\u0917\u0932._\u092c\u0941\u0927._\u092c\u093f\u0939\u093f._\u0936\u0941\u0915\u094d\u0930._\u0936\u0928\u093f.".split("_"),weekdaysMin:"\u0906._\u0938\u094b._\u092e\u0902._\u092c\u0941._\u092c\u093f._\u0936\u0941._\u0936.".split("_"),months:"\u091c\u0928\u0935\u0930\u0940_\u092b\u0947\u092c\u094d\u0930\u0941\u0935\u0930\u0940_\u092e\u093e\u0930\u094d\u091a_\u0905\u092a\u094d\u0930\u093f\u0932_\u092e\u0947_\u091c\u0941\u0928_\u091c\u0941\u0932\u093e\u0908_\u0905\u0917\u0937\u094d\u091f_\u0938\u0947\u092a\u094d\u091f\u0947\u092e\u094d\u092c\u0930_\u0905\u0915\u094d\u091f\u094b\u092c\u0930_\u0928\u094b\u092d\u0947\u092e\u094d\u092c\u0930_\u0921\u093f\u0938\u0947\u092e\u094d\u092c\u0930".split("_"),monthsShort:"\u091c\u0928._\u092b\u0947\u092c\u094d\u0930\u0941._\u092e\u093e\u0930\u094d\u091a_\u0905\u092a\u094d\u0930\u093f._\u092e\u0908_\u091c\u0941\u0928_\u091c\u0941\u0932\u093e\u0908._\u0905\u0917._\u0938\u0947\u092a\u094d\u091f._\u0905\u0915\u094d\u091f\u094b._\u0928\u094b\u092d\u0947._\u0921\u093f\u0938\u0947.".split("_"),relativeTime:{future:"%s \u092a\u091b\u093f",past:"%s \u0905\u0918\u093f",s:"\u0938\u0947\u0915\u0947\u0928\u094d\u0921",m:"\u090f\u0915 \u092e\u093f\u0928\u0947\u091f",mm:"%d \u092e\u093f\u0928\u0947\u091f",h:"\u0918\u0928\u094d\u091f\u093e",hh:"%d \u0918\u0928\u094d\u091f\u093e",d:"\u090f\u0915 \u0926\u093f\u0928",dd:"%d \u0926\u093f\u0928",M:"\u090f\u0915 \u092e\u0939\u093f\u0928\u093e",MM:"%d \u092e\u0939\u093f\u0928\u093e",y:"\u090f\u0915 \u0935\u0930\u094d\u0937",yy:"%d \u0935\u0930\u094d\u0937"},ordinal:function(_){return(""+_).replace(/\d/g,(function(_){return"\u0966\u0967\u0968\u0969\u096a\u096b\u096c\u096d\u096e\u096f"[_]}))},formats:{LT:"A\u0915\u094b h:mm \u092c\u091c\u0947",LTS:"A\u0915\u094b h:mm:ss \u092c\u091c\u0947",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A\u0915\u094b h:mm \u092c\u091c\u0947",LLLL:"dddd, D MMMM YYYY, A\u0915\u094b h:mm \u092c\u091c\u0947"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4847.63c73f0a.chunk.js b/ydb/core/viewer/monitoring/static/js/4847.63c73f0a.chunk.js deleted file mode 100644 index c24c9e252386..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4847.63c73f0a.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4847],{34847:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ug-cn",weekdays:"\u064a\u06d5\u0643\u0634\u06d5\u0646\u0628\u06d5_\u062f\u06c8\u0634\u06d5\u0646\u0628\u06d5_\u0633\u06d5\u064a\u0634\u06d5\u0646\u0628\u06d5_\u0686\u0627\u0631\u0634\u06d5\u0646\u0628\u06d5_\u067e\u06d5\u064a\u0634\u06d5\u0646\u0628\u06d5_\u062c\u06c8\u0645\u06d5_\u0634\u06d5\u0646\u0628\u06d5".split("_"),months:"\u064a\u0627\u0646\u06cb\u0627\u0631_\u0641\u06d0\u06cb\u0631\u0627\u0644_\u0645\u0627\u0631\u062a_\u0626\u0627\u067e\u0631\u06d0\u0644_\u0645\u0627\u064a_\u0626\u0649\u064a\u06c7\u0646_\u0626\u0649\u064a\u06c7\u0644_\u0626\u0627\u06cb\u063a\u06c7\u0633\u062a_\u0633\u06d0\u0646\u062a\u06d5\u0628\u0649\u0631_\u0626\u06c6\u0643\u062a\u06d5\u0628\u0649\u0631_\u0646\u0648\u064a\u0627\u0628\u0649\u0631_\u062f\u06d0\u0643\u0627\u0628\u0649\u0631".split("_"),weekStart:1,weekdaysShort:"\u064a\u06d5_\u062f\u06c8_\u0633\u06d5_\u0686\u0627_\u067e\u06d5_\u062c\u06c8_\u0634\u06d5".split("_"),monthsShort:"\u064a\u0627\u0646\u06cb\u0627\u0631_\u0641\u06d0\u06cb\u0631\u0627\u0644_\u0645\u0627\u0631\u062a_\u0626\u0627\u067e\u0631\u06d0\u0644_\u0645\u0627\u064a_\u0626\u0649\u064a\u06c7\u0646_\u0626\u0649\u064a\u06c7\u0644_\u0626\u0627\u06cb\u063a\u06c7\u0633\u062a_\u0633\u06d0\u0646\u062a\u06d5\u0628\u0649\u0631_\u0626\u06c6\u0643\u062a\u06d5\u0628\u0649\u0631_\u0646\u0648\u064a\u0627\u0628\u0649\u0631_\u062f\u06d0\u0643\u0627\u0628\u0649\u0631".split("_"),weekdaysMin:"\u064a\u06d5_\u062f\u06c8_\u0633\u06d5_\u0686\u0627_\u067e\u06d5_\u062c\u06c8_\u0634\u06d5".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY-\u064a\u0649\u0644\u0649M-\u0626\u0627\u064a\u0646\u0649\u06adD-\u0643\u06c8\u0646\u0649",LLL:"YYYY-\u064a\u0649\u0644\u0649M-\u0626\u0627\u064a\u0646\u0649\u06adD-\u0643\u06c8\u0646\u0649\u060c HH:mm",LLLL:"dddd\u060c YYYY-\u064a\u0649\u0644\u0649M-\u0626\u0627\u064a\u0646\u0649\u06adD-\u0643\u06c8\u0646\u0649\u060c HH:mm"},relativeTime:{future:"%s \u0643\u06d0\u064a\u0649\u0646",past:"%s \u0628\u06c7\u0631\u06c7\u0646",s:"\u0646\u06d5\u0686\u0686\u06d5 \u0633\u06d0\u0643\u0648\u0646\u062a",m:"\u0628\u0649\u0631 \u0645\u0649\u0646\u06c7\u062a",mm:"%d \u0645\u0649\u0646\u06c7\u062a",h:"\u0628\u0649\u0631 \u0633\u0627\u0626\u06d5\u062a",hh:"%d \u0633\u0627\u0626\u06d5\u062a",d:"\u0628\u0649\u0631 \u0643\u06c8\u0646",dd:"%d \u0643\u06c8\u0646",M:"\u0628\u0649\u0631 \u0626\u0627\u064a",MM:"%d \u0626\u0627\u064a",y:"\u0628\u0649\u0631 \u064a\u0649\u0644",yy:"%d \u064a\u0649\u0644"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/48633.41f9d3a3.chunk.js b/ydb/core/viewer/monitoring/static/js/48633.41f9d3a3.chunk.js new file mode 100644 index 000000000000..0962462df471 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/48633.41f9d3a3.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[48633],{48633:function(d,e,_){d.exports=function(d){"use strict";function e(d){return d&&"object"==typeof d&&"default"in d?d:{default:d}}var _=e(d),a={name:"cy",weekdays:"Dydd Sul_Dydd Llun_Dydd Mawrth_Dydd Mercher_Dydd Iau_Dydd Gwener_Dydd Sadwrn".split("_"),months:"Ionawr_Chwefror_Mawrth_Ebrill_Mai_Mehefin_Gorffennaf_Awst_Medi_Hydref_Tachwedd_Rhagfyr".split("_"),weekStart:1,weekdaysShort:"Sul_Llun_Maw_Mer_Iau_Gwe_Sad".split("_"),monthsShort:"Ion_Chwe_Maw_Ebr_Mai_Meh_Gor_Aws_Med_Hyd_Tach_Rhag".split("_"),weekdaysMin:"Su_Ll_Ma_Me_Ia_Gw_Sa".split("_"),ordinal:function(d){return d},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"mewn %s",past:"%s yn \xf4l",s:"ychydig eiliadau",m:"munud",mm:"%d munud",h:"awr",hh:"%d awr",d:"diwrnod",dd:"%d diwrnod",M:"mis",MM:"%d mis",y:"blwyddyn",yy:"%d flynedd"}};return _.default.locale(a,null,!0),a}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4870.1916a88d.chunk.js b/ydb/core/viewer/monitoring/static/js/4870.1916a88d.chunk.js deleted file mode 100644 index f57deacb2365..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4870.1916a88d.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4870.1916a88d.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4870],{84870:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>m,language:()=>b});var r,o,l=t(80781),a=Object.defineProperty,i=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,u=Object.prototype.hasOwnProperty,d=(e,n,t,r)=>{if(n&&"object"===typeof n||"function"===typeof n)for(let o of c(n))u.call(e,o)||o===t||a(e,o,{get:()=>n[o],enumerable:!(r=i(n,o))||r.enumerable});return e},s={};d(s,r=l,"default"),o&&d(o,r,"default");var m={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{offSide:!0},onEnterRules:[{beforeText:/:\s*$/,action:{indentAction:s.languages.IndentAction.Indent}}]},b={tokenPostfix:".yaml",brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.square",open:"[",close:"]"}],keywords:["true","True","TRUE","false","False","FALSE","null","Null","Null","~"],numberInteger:/(?:0|[+-]?[0-9]+)/,numberFloat:/(?:0|[+-]?[0-9]+)(?:\.[0-9]+)?(?:e[-+][1-9][0-9]*)?/,numberOctal:/0o[0-7]+/,numberHex:/0x[0-9a-fA-F]+/,numberInfinity:/[+-]?\.(?:inf|Inf|INF)/,numberNaN:/\.(?:nan|Nan|NAN)/,numberDate:/\d{4}-\d\d-\d\d([Tt ]\d\d:\d\d:\d\d(\.\d+)?(( ?[+-]\d\d?(:\d\d)?)|Z)?)?/,escapes:/\\(?:[btnfr\\"']|[0-7][0-7]?|[0-3][0-7]{2})/,tokenizer:{root:[{include:"@whitespace"},{include:"@comment"},[/%[^ ]+.*$/,"meta.directive"],[/---/,"operators.directivesEnd"],[/\.{3}/,"operators.documentEnd"],[/[-?:](?= )/,"operators"],{include:"@anchor"},{include:"@tagHandle"},{include:"@flowCollections"},{include:"@blockStyle"},[/@numberInteger(?![ \t]*\S+)/,"number"],[/@numberFloat(?![ \t]*\S+)/,"number.float"],[/@numberOctal(?![ \t]*\S+)/,"number.octal"],[/@numberHex(?![ \t]*\S+)/,"number.hex"],[/@numberInfinity(?![ \t]*\S+)/,"number.infinity"],[/@numberNaN(?![ \t]*\S+)/,"number.nan"],[/@numberDate(?![ \t]*\S+)/,"number.date"],[/(".*?"|'.*?'|[^#'"]*?)([ \t]*)(:)( |$)/,["type","white","operators","white"]],{include:"@flowScalars"},[/.+?(?=(\s+#|$))/,{cases:{"@keywords":"keyword","@default":"string"}}]],object:[{include:"@whitespace"},{include:"@comment"},[/\}/,"@brackets","@pop"],[/,/,"delimiter.comma"],[/:(?= )/,"operators"],[/(?:".*?"|'.*?'|[^,\{\[]+?)(?=: )/,"type"],{include:"@flowCollections"},{include:"@flowScalars"},{include:"@tagHandle"},{include:"@anchor"},{include:"@flowNumber"},[/[^\},]+/,{cases:{"@keywords":"keyword","@default":"string"}}]],array:[{include:"@whitespace"},{include:"@comment"},[/\]/,"@brackets","@pop"],[/,/,"delimiter.comma"],{include:"@flowCollections"},{include:"@flowScalars"},{include:"@tagHandle"},{include:"@anchor"},{include:"@flowNumber"},[/[^\],]+/,{cases:{"@keywords":"keyword","@default":"string"}}]],multiString:[[/^( +).+$/,"string","@multiStringContinued.$1"]],multiStringContinued:[[/^( *).+$/,{cases:{"$1==$S2":"string","@default":{token:"@rematch",next:"@popall"}}}]],whitespace:[[/[ \t\r\n]+/,"white"]],comment:[[/#.*$/,"comment"]],flowCollections:[[/\[/,"@brackets","@array"],[/\{/,"@brackets","@object"]],flowScalars:[[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'[^']*'/,"string"],[/"/,"string","@doubleQuotedString"]],doubleQuotedString:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],blockStyle:[[/[>|][0-9]*[+-]?$/,"operators","@multiString"]],flowNumber:[[/@numberInteger(?=[ \t]*[,\]\}])/,"number"],[/@numberFloat(?=[ \t]*[,\]\}])/,"number.float"],[/@numberOctal(?=[ \t]*[,\]\}])/,"number.octal"],[/@numberHex(?=[ \t]*[,\]\}])/,"number.hex"],[/@numberInfinity(?=[ \t]*[,\]\}])/,"number.infinity"],[/@numberNaN(?=[ \t]*[,\]\}])/,"number.nan"],[/@numberDate(?=[ \t]*[,\]\}])/,"number.date"]],tagHandle:[[/\![^ ]*/,"tag"]],anchor:[[/[&*][^ ]+/,"namespace"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4872.2eea7e0a.chunk.js b/ydb/core/viewer/monitoring/static/js/4872.2eea7e0a.chunk.js deleted file mode 100644 index b5a32b52b87d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4872.2eea7e0a.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 4872.2eea7e0a.chunk.js.LICENSE.txt */ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4872],{16929:(n,t,r)=>{"use strict";r.d(t,{A:()=>u});var e=r(59284);const u=n=>e.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},n),e.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0m-6 2.5a1 1 0 1 1-2 0 1 1 0 0 1 2 0M8.75 5a.75.75 0 0 0-1.5 0v2.5a.75.75 0 0 0 1.5 0z",clipRule:"evenodd"}))},45720:(n,t,r)=>{"use strict";r.d(t,{A:()=>u});var e=r(59284);const u=n=>e.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},n),e.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14m1-9.5a1 1 0 1 1-2 0 1 1 0 0 1 2 0M8 7.75a.75.75 0 0 1 .75.75V11a.75.75 0 0 1-1.5 0V8.5A.75.75 0 0 1 8 7.75",clipRule:"evenodd"}))},79879:(n,t,r)=>{"use strict";r.d(t,{A:()=>u});var e=r(59284);const u=n=>e.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},n),e.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"m3.003 4.702 4.22-2.025a1.8 1.8 0 0 1 1.554 0l4.22 2.025a.89.89 0 0 1 .503.8V6a8.55 8.55 0 0 1-3.941 7.201l-.986.631a1.06 1.06 0 0 1-1.146 0l-.986-.63A8.55 8.55 0 0 1 2.5 6v-.498c0-.341.196-.652.503-.8m3.57-3.377L2.354 3.35A2.39 2.39 0 0 0 1 5.502V6a10.05 10.05 0 0 0 4.632 8.465l.986.63a2.56 2.56 0 0 0 2.764 0l.986-.63A10.05 10.05 0 0 0 15 6v-.498c0-.918-.526-1.755-1.354-2.152l-4.22-2.025a3.3 3.3 0 0 0-2.852 0M9.5 7a1.5 1.5 0 0 1-.75 1.3v1.95a.75.75 0 0 1-1.5 0V8.3A1.5 1.5 0 1 1 9.5 7",clipRule:"evenodd"}))},71153:(n,t,r)=>{"use strict";r.d(t,{A:()=>u});var e=r(59284);const u=n=>e.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},n),e.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M5.835 2.244c.963-1.665 3.367-1.665 4.33 0l4.916 8.505c.964 1.666-.24 3.751-2.164 3.751H3.083c-1.925 0-3.128-2.085-2.165-3.751zM8 5a.75.75 0 0 1 .75.75v2a.75.75 0 1 1-1.5 0v-2A.75.75 0 0 1 8 5m1 5.75a1 1 0 1 1-2 0 1 1 0 0 1 2 0",clipRule:"evenodd"}))},89169:(n,t,r)=>{"use strict";r.d(t,{E:()=>i});var e=r(59284);const u=(0,r(69220).om)("skeleton");function i({className:n,style:t,qa:r}){return e.createElement("div",{className:u(null,n),style:t,"data-qa":r})}},13847:function(n,t,r){var e;n=r.nmd(n),function(){var u,i="Expected a function",o="__lodash_hash_undefined__",f="__lodash_placeholder__",a=16,c=32,l=64,s=128,h=256,p=1/0,v=9007199254740991,_=NaN,g=4294967295,y=[["ary",s],["bind",1],["bindKey",2],["curry",8],["curryRight",a],["flip",512],["partial",c],["partialRight",l],["rearg",h]],d="[object Arguments]",w="[object Array]",b="[object Boolean]",m="[object Date]",x="[object Error]",A="[object Function]",j="[object GeneratorFunction]",k="[object Map]",E="[object Number]",R="[object Object]",O="[object Promise]",I="[object RegExp]",z="[object Set]",S="[object String]",C="[object Symbol]",L="[object WeakMap]",W="[object ArrayBuffer]",B="[object DataView]",T="[object Float32Array]",U="[object Float64Array]",M="[object Int8Array]",$="[object Int16Array]",D="[object Int32Array]",N="[object Uint8Array]",F="[object Uint8ClampedArray]",q="[object Uint16Array]",P="[object Uint32Array]",V=/\b__p \+= '';/g,Z=/\b(__p \+=) '' \+/g,K=/(__e\(.*?\)|\b__t\)) \+\n'';/g,G=/&(?:amp|lt|gt|quot|#39);/g,H=/[&<>"']/g,J=RegExp(G.source),Y=RegExp(H.source),Q=/<%-([\s\S]+?)%>/g,X=/<%([\s\S]+?)%>/g,nn=/<%=([\s\S]+?)%>/g,tn=/\.|\[(?:[^[\]]*|(["'])(?:(?!\1)[^\\]|\\.)*?\1)\]/,rn=/^\w*$/,en=/[^.[\]]+|\[(?:(-?\d+(?:\.\d+)?)|(["'])((?:(?!\2)[^\\]|\\.)*?)\2)\]|(?=(?:\.|\[\])(?:\.|\[\]|$))/g,un=/[\\^$.*+?()[\]{}|]/g,on=RegExp(un.source),fn=/^\s+/,an=/\s/,cn=/\{(?:\n\/\* \[wrapped with .+\] \*\/)?\n?/,ln=/\{\n\/\* \[wrapped with (.+)\] \*/,sn=/,? & /,hn=/[^\x00-\x2f\x3a-\x40\x5b-\x60\x7b-\x7f]+/g,pn=/[()=,{}\[\]\/\s]/,vn=/\\(\\)?/g,_n=/\$\{([^\\}]*(?:\\.[^\\}]*)*)\}/g,gn=/\w*$/,yn=/^[-+]0x[0-9a-f]+$/i,dn=/^0b[01]+$/i,wn=/^\[object .+?Constructor\]$/,bn=/^0o[0-7]+$/i,mn=/^(?:0|[1-9]\d*)$/,xn=/[\xc0-\xd6\xd8-\xf6\xf8-\xff\u0100-\u017f]/g,An=/($^)/,jn=/['\n\r\u2028\u2029\\]/g,kn="\\ud800-\\udfff",En="\\u0300-\\u036f\\ufe20-\\ufe2f\\u20d0-\\u20ff",Rn="\\u2700-\\u27bf",On="a-z\\xdf-\\xf6\\xf8-\\xff",In="A-Z\\xc0-\\xd6\\xd8-\\xde",zn="\\ufe0e\\ufe0f",Sn="\\xac\\xb1\\xd7\\xf7\\x00-\\x2f\\x3a-\\x40\\x5b-\\x60\\x7b-\\xbf\\u2000-\\u206f \\t\\x0b\\f\\xa0\\ufeff\\n\\r\\u2028\\u2029\\u1680\\u180e\\u2000\\u2001\\u2002\\u2003\\u2004\\u2005\\u2006\\u2007\\u2008\\u2009\\u200a\\u202f\\u205f\\u3000",Cn="['\u2019]",Ln="["+kn+"]",Wn="["+Sn+"]",Bn="["+En+"]",Tn="\\d+",Un="["+Rn+"]",Mn="["+On+"]",$n="[^"+kn+Sn+Tn+Rn+On+In+"]",Dn="\\ud83c[\\udffb-\\udfff]",Nn="[^"+kn+"]",Fn="(?:\\ud83c[\\udde6-\\uddff]){2}",qn="[\\ud800-\\udbff][\\udc00-\\udfff]",Pn="["+In+"]",Vn="\\u200d",Zn="(?:"+Mn+"|"+$n+")",Kn="(?:"+Pn+"|"+$n+")",Gn="(?:['\u2019](?:d|ll|m|re|s|t|ve))?",Hn="(?:['\u2019](?:D|LL|M|RE|S|T|VE))?",Jn="(?:"+Bn+"|"+Dn+")"+"?",Yn="["+zn+"]?",Qn=Yn+Jn+("(?:"+Vn+"(?:"+[Nn,Fn,qn].join("|")+")"+Yn+Jn+")*"),Xn="(?:"+[Un,Fn,qn].join("|")+")"+Qn,nt="(?:"+[Nn+Bn+"?",Bn,Fn,qn,Ln].join("|")+")",tt=RegExp(Cn,"g"),rt=RegExp(Bn,"g"),et=RegExp(Dn+"(?="+Dn+")|"+nt+Qn,"g"),ut=RegExp([Pn+"?"+Mn+"+"+Gn+"(?="+[Wn,Pn,"$"].join("|")+")",Kn+"+"+Hn+"(?="+[Wn,Pn+Zn,"$"].join("|")+")",Pn+"?"+Zn+"+"+Gn,Pn+"+"+Hn,"\\d*(?:1ST|2ND|3RD|(?![123])\\dTH)(?=\\b|[a-z_])","\\d*(?:1st|2nd|3rd|(?![123])\\dth)(?=\\b|[A-Z_])",Tn,Xn].join("|"),"g"),it=RegExp("["+Vn+kn+En+zn+"]"),ot=/[a-z][A-Z]|[A-Z]{2}[a-z]|[0-9][a-zA-Z]|[a-zA-Z][0-9]|[^a-zA-Z0-9 ]/,ft=["Array","Buffer","DataView","Date","Error","Float32Array","Float64Array","Function","Int8Array","Int16Array","Int32Array","Map","Math","Object","Promise","RegExp","Set","String","Symbol","TypeError","Uint8Array","Uint8ClampedArray","Uint16Array","Uint32Array","WeakMap","_","clearTimeout","isFinite","parseInt","setTimeout"],at=-1,ct={};ct[T]=ct[U]=ct[M]=ct[$]=ct[D]=ct[N]=ct[F]=ct[q]=ct[P]=!0,ct[d]=ct[w]=ct[W]=ct[b]=ct[B]=ct[m]=ct[x]=ct[A]=ct[k]=ct[E]=ct[R]=ct[I]=ct[z]=ct[S]=ct[L]=!1;var lt={};lt[d]=lt[w]=lt[W]=lt[B]=lt[b]=lt[m]=lt[T]=lt[U]=lt[M]=lt[$]=lt[D]=lt[k]=lt[E]=lt[R]=lt[I]=lt[z]=lt[S]=lt[C]=lt[N]=lt[F]=lt[q]=lt[P]=!0,lt[x]=lt[A]=lt[L]=!1;var st={"\\":"\\","'":"'","\n":"n","\r":"r","\u2028":"u2028","\u2029":"u2029"},ht=parseFloat,pt=parseInt,vt="object"==typeof r.g&&r.g&&r.g.Object===Object&&r.g,_t="object"==typeof self&&self&&self.Object===Object&&self,gt=vt||_t||Function("return this")(),yt=t&&!t.nodeType&&t,dt=yt&&n&&!n.nodeType&&n,wt=dt&&dt.exports===yt,bt=wt&&vt.process,mt=function(){try{var n=dt&&dt.require&&dt.require("util").types;return n||bt&&bt.binding&&bt.binding("util")}catch(t){}}(),xt=mt&&mt.isArrayBuffer,At=mt&&mt.isDate,jt=mt&&mt.isMap,kt=mt&&mt.isRegExp,Et=mt&&mt.isSet,Rt=mt&&mt.isTypedArray;function Ot(n,t,r){switch(r.length){case 0:return n.call(t);case 1:return n.call(t,r[0]);case 2:return n.call(t,r[0],r[1]);case 3:return n.call(t,r[0],r[1],r[2])}return n.apply(t,r)}function It(n,t,r,e){for(var u=-1,i=null==n?0:n.length;++u-1}function Bt(n,t,r){for(var e=-1,u=null==n?0:n.length;++e-1;);return r}function ur(n,t){for(var r=n.length;r--&&Pt(t,n[r],0)>-1;);return r}var ir=Ht({"\xc0":"A","\xc1":"A","\xc2":"A","\xc3":"A","\xc4":"A","\xc5":"A","\xe0":"a","\xe1":"a","\xe2":"a","\xe3":"a","\xe4":"a","\xe5":"a","\xc7":"C","\xe7":"c","\xd0":"D","\xf0":"d","\xc8":"E","\xc9":"E","\xca":"E","\xcb":"E","\xe8":"e","\xe9":"e","\xea":"e","\xeb":"e","\xcc":"I","\xcd":"I","\xce":"I","\xcf":"I","\xec":"i","\xed":"i","\xee":"i","\xef":"i","\xd1":"N","\xf1":"n","\xd2":"O","\xd3":"O","\xd4":"O","\xd5":"O","\xd6":"O","\xd8":"O","\xf2":"o","\xf3":"o","\xf4":"o","\xf5":"o","\xf6":"o","\xf8":"o","\xd9":"U","\xda":"U","\xdb":"U","\xdc":"U","\xf9":"u","\xfa":"u","\xfb":"u","\xfc":"u","\xdd":"Y","\xfd":"y","\xff":"y","\xc6":"Ae","\xe6":"ae","\xde":"Th","\xfe":"th","\xdf":"ss","\u0100":"A","\u0102":"A","\u0104":"A","\u0101":"a","\u0103":"a","\u0105":"a","\u0106":"C","\u0108":"C","\u010a":"C","\u010c":"C","\u0107":"c","\u0109":"c","\u010b":"c","\u010d":"c","\u010e":"D","\u0110":"D","\u010f":"d","\u0111":"d","\u0112":"E","\u0114":"E","\u0116":"E","\u0118":"E","\u011a":"E","\u0113":"e","\u0115":"e","\u0117":"e","\u0119":"e","\u011b":"e","\u011c":"G","\u011e":"G","\u0120":"G","\u0122":"G","\u011d":"g","\u011f":"g","\u0121":"g","\u0123":"g","\u0124":"H","\u0126":"H","\u0125":"h","\u0127":"h","\u0128":"I","\u012a":"I","\u012c":"I","\u012e":"I","\u0130":"I","\u0129":"i","\u012b":"i","\u012d":"i","\u012f":"i","\u0131":"i","\u0134":"J","\u0135":"j","\u0136":"K","\u0137":"k","\u0138":"k","\u0139":"L","\u013b":"L","\u013d":"L","\u013f":"L","\u0141":"L","\u013a":"l","\u013c":"l","\u013e":"l","\u0140":"l","\u0142":"l","\u0143":"N","\u0145":"N","\u0147":"N","\u014a":"N","\u0144":"n","\u0146":"n","\u0148":"n","\u014b":"n","\u014c":"O","\u014e":"O","\u0150":"O","\u014d":"o","\u014f":"o","\u0151":"o","\u0154":"R","\u0156":"R","\u0158":"R","\u0155":"r","\u0157":"r","\u0159":"r","\u015a":"S","\u015c":"S","\u015e":"S","\u0160":"S","\u015b":"s","\u015d":"s","\u015f":"s","\u0161":"s","\u0162":"T","\u0164":"T","\u0166":"T","\u0163":"t","\u0165":"t","\u0167":"t","\u0168":"U","\u016a":"U","\u016c":"U","\u016e":"U","\u0170":"U","\u0172":"U","\u0169":"u","\u016b":"u","\u016d":"u","\u016f":"u","\u0171":"u","\u0173":"u","\u0174":"W","\u0175":"w","\u0176":"Y","\u0177":"y","\u0178":"Y","\u0179":"Z","\u017b":"Z","\u017d":"Z","\u017a":"z","\u017c":"z","\u017e":"z","\u0132":"IJ","\u0133":"ij","\u0152":"Oe","\u0153":"oe","\u0149":"'n","\u017f":"s"}),or=Ht({"&":"&","<":"<",">":">",'"':""","'":"'"});function fr(n){return"\\"+st[n]}function ar(n){return it.test(n)}function cr(n){var t=-1,r=Array(n.size);return n.forEach((function(n,e){r[++t]=[e,n]})),r}function lr(n,t){return function(r){return n(t(r))}}function sr(n,t){for(var r=-1,e=n.length,u=0,i=[];++r",""":'"',"'":"'"});var dr=function n(t){var r=(t=null==t?gt:dr.defaults(gt.Object(),t,dr.pick(gt,ft))).Array,e=t.Date,an=t.Error,kn=t.Function,En=t.Math,Rn=t.Object,On=t.RegExp,In=t.String,zn=t.TypeError,Sn=r.prototype,Cn=kn.prototype,Ln=Rn.prototype,Wn=t["__core-js_shared__"],Bn=Cn.toString,Tn=Ln.hasOwnProperty,Un=0,Mn=function(){var n=/[^.]+$/.exec(Wn&&Wn.keys&&Wn.keys.IE_PROTO||"");return n?"Symbol(src)_1."+n:""}(),$n=Ln.toString,Dn=Bn.call(Rn),Nn=gt._,Fn=On("^"+Bn.call(Tn).replace(un,"\\$&").replace(/hasOwnProperty|(function).*?(?=\\\()| for .+?(?=\\\])/g,"$1.*?")+"$"),qn=wt?t.Buffer:u,Pn=t.Symbol,Vn=t.Uint8Array,Zn=qn?qn.allocUnsafe:u,Kn=lr(Rn.getPrototypeOf,Rn),Gn=Rn.create,Hn=Ln.propertyIsEnumerable,Jn=Sn.splice,Yn=Pn?Pn.isConcatSpreadable:u,Qn=Pn?Pn.iterator:u,Xn=Pn?Pn.toStringTag:u,nt=function(){try{var n=si(Rn,"defineProperty");return n({},"",{}),n}catch(t){}}(),et=t.clearTimeout!==gt.clearTimeout&&t.clearTimeout,it=e&&e.now!==gt.Date.now&&e.now,st=t.setTimeout!==gt.setTimeout&&t.setTimeout,vt=En.ceil,_t=En.floor,yt=Rn.getOwnPropertySymbols,dt=qn?qn.isBuffer:u,bt=t.isFinite,mt=Sn.join,Nt=lr(Rn.keys,Rn),Ht=En.max,wr=En.min,br=e.now,mr=t.parseInt,xr=En.random,Ar=Sn.reverse,jr=si(t,"DataView"),kr=si(t,"Map"),Er=si(t,"Promise"),Rr=si(t,"Set"),Or=si(t,"WeakMap"),Ir=si(Rn,"create"),zr=Or&&new Or,Sr={},Cr=Ui(jr),Lr=Ui(kr),Wr=Ui(Er),Br=Ui(Rr),Tr=Ui(Or),Ur=Pn?Pn.prototype:u,Mr=Ur?Ur.valueOf:u,$r=Ur?Ur.toString:u;function Dr(n){if(tf(n)&&!Po(n)&&!(n instanceof Pr)){if(n instanceof qr)return n;if(Tn.call(n,"__wrapped__"))return Mi(n)}return new qr(n)}var Nr=function(){function n(){}return function(t){if(!nf(t))return{};if(Gn)return Gn(t);n.prototype=t;var r=new n;return n.prototype=u,r}}();function Fr(){}function qr(n,t){this.__wrapped__=n,this.__actions__=[],this.__chain__=!!t,this.__index__=0,this.__values__=u}function Pr(n){this.__wrapped__=n,this.__actions__=[],this.__dir__=1,this.__filtered__=!1,this.__iteratees__=[],this.__takeCount__=g,this.__views__=[]}function Vr(n){var t=-1,r=null==n?0:n.length;for(this.clear();++t=t?n:t)),n}function ae(n,t,r,e,i,o){var f,a=1&t,c=2&t,l=4&t;if(r&&(f=i?r(n,e,i,o):r(n)),f!==u)return f;if(!nf(n))return n;var s=Po(n);if(s){if(f=function(n){var t=n.length,r=new n.constructor(t);t&&"string"==typeof n[0]&&Tn.call(n,"index")&&(r.index=n.index,r.input=n.input);return r}(n),!a)return Iu(n,f)}else{var h=vi(n),p=h==A||h==j;if(Go(n))return Au(n,a);if(h==R||h==d||p&&!i){if(f=c||p?{}:gi(n),!a)return c?function(n,t){return zu(n,pi(n),t)}(n,function(n,t){return n&&zu(t,Lf(t),n)}(f,n)):function(n,t){return zu(n,hi(n),t)}(n,ue(f,n))}else{if(!lt[h])return i?n:{};f=function(n,t,r){var e=n.constructor;switch(t){case W:return ju(n);case b:case m:return new e(+n);case B:return function(n,t){var r=t?ju(n.buffer):n.buffer;return new n.constructor(r,n.byteOffset,n.byteLength)}(n,r);case T:case U:case M:case $:case D:case N:case F:case q:case P:return ku(n,r);case k:return new e;case E:case S:return new e(n);case I:return function(n){var t=new n.constructor(n.source,gn.exec(n));return t.lastIndex=n.lastIndex,t}(n);case z:return new e;case C:return u=n,Mr?Rn(Mr.call(u)):{}}var u}(n,h,a)}}o||(o=new Hr);var v=o.get(n);if(v)return v;o.set(n,f),ff(n)?n.forEach((function(e){f.add(ae(e,t,r,e,n,o))})):rf(n)&&n.forEach((function(e,u){f.set(u,ae(e,t,r,u,n,o))}));var _=s?u:(l?c?ui:ei:c?Lf:Cf)(n);return zt(_||n,(function(e,u){_&&(e=n[u=e]),te(f,u,ae(e,t,r,u,n,o))})),f}function ce(n,t,r){var e=r.length;if(null==n)return!e;for(n=Rn(n);e--;){var i=r[e],o=t[i],f=n[i];if(f===u&&!(i in n)||!o(f))return!1}return!0}function le(n,t,r){if("function"!=typeof n)throw new zn(i);return zi((function(){n.apply(u,r)}),t)}function se(n,t,r,e){var u=-1,i=Wt,o=!0,f=n.length,a=[],c=t.length;if(!f)return a;r&&(t=Tt(t,nr(r))),e?(i=Bt,o=!1):t.length>=200&&(i=rr,o=!1,t=new Gr(t));n:for(;++u-1},Zr.prototype.set=function(n,t){var r=this.__data__,e=re(r,n);return e<0?(++this.size,r.push([n,t])):r[e][1]=t,this},Kr.prototype.clear=function(){this.size=0,this.__data__={hash:new Vr,map:new(kr||Zr),string:new Vr}},Kr.prototype.delete=function(n){var t=ci(this,n).delete(n);return this.size-=t?1:0,t},Kr.prototype.get=function(n){return ci(this,n).get(n)},Kr.prototype.has=function(n){return ci(this,n).has(n)},Kr.prototype.set=function(n,t){var r=ci(this,n),e=r.size;return r.set(n,t),this.size+=r.size==e?0:1,this},Gr.prototype.add=Gr.prototype.push=function(n){return this.__data__.set(n,o),this},Gr.prototype.has=function(n){return this.__data__.has(n)},Hr.prototype.clear=function(){this.__data__=new Zr,this.size=0},Hr.prototype.delete=function(n){var t=this.__data__,r=t.delete(n);return this.size=t.size,r},Hr.prototype.get=function(n){return this.__data__.get(n)},Hr.prototype.has=function(n){return this.__data__.has(n)},Hr.prototype.set=function(n,t){var r=this.__data__;if(r instanceof Zr){var e=r.__data__;if(!kr||e.length<199)return e.push([n,t]),this.size=++r.size,this;r=this.__data__=new Kr(e)}return r.set(n,t),this.size=r.size,this};var he=Lu(be),pe=Lu(me,!0);function ve(n,t){var r=!0;return he(n,(function(n,e,u){return r=!!t(n,e,u)})),r}function _e(n,t,r){for(var e=-1,i=n.length;++e0&&r(f)?t>1?ye(f,t-1,r,e,u):Ut(u,f):e||(u[u.length]=f)}return u}var de=Wu(),we=Wu(!0);function be(n,t){return n&&de(n,t,Cf)}function me(n,t){return n&&we(n,t,Cf)}function xe(n,t){return Lt(t,(function(t){return Yo(n[t])}))}function Ae(n,t){for(var r=0,e=(t=wu(t,n)).length;null!=n&&rt}function Re(n,t){return null!=n&&Tn.call(n,t)}function Oe(n,t){return null!=n&&t in Rn(n)}function Ie(n,t,e){for(var i=e?Bt:Wt,o=n[0].length,f=n.length,a=f,c=r(f),l=1/0,s=[];a--;){var h=n[a];a&&t&&(h=Tt(h,nr(t))),l=wr(h.length,l),c[a]=!e&&(t||o>=120&&h.length>=120)?new Gr(a&&h):u}h=n[0];var p=-1,v=c[0];n:for(;++p=f?a:a*("desc"==r[e]?-1:1)}return n.index-t.index}(n,t,r)}))}function Ve(n,t,r){for(var e=-1,u=t.length,i={};++e-1;)f!==n&&Jn.call(f,a,1),Jn.call(n,a,1);return n}function Ke(n,t){for(var r=n?t.length:0,e=r-1;r--;){var u=t[r];if(r==e||u!==i){var i=u;di(u)?Jn.call(n,u,1):su(n,u)}}return n}function Ge(n,t){return n+_t(xr()*(t-n+1))}function He(n,t){var r="";if(!n||t<1||t>v)return r;do{t%2&&(r+=n),(t=_t(t/2))&&(n+=n)}while(t);return r}function Je(n,t){return Si(Ei(n,t,ua),n+"")}function Ye(n){return Yr(Nf(n))}function Qe(n,t){var r=Nf(n);return Wi(r,fe(t,0,r.length))}function Xe(n,t,r,e){if(!nf(n))return n;for(var i=-1,o=(t=wu(t,n)).length,f=o-1,a=n;null!=a&&++ii?0:i+t),(e=e>i?i:e)<0&&(e+=i),i=t>e?0:e-t>>>0,t>>>=0;for(var o=r(i);++u>>1,o=n[i];null!==o&&!cf(o)&&(r?o<=t:o=200){var c=t?null:Hu(n);if(c)return hr(c);o=!1,u=rr,a=new Gr}else a=t?[]:f;n:for(;++e=e?n:eu(n,t,r)}var xu=et||function(n){return gt.clearTimeout(n)};function Au(n,t){if(t)return n.slice();var r=n.length,e=Zn?Zn(r):new n.constructor(r);return n.copy(e),e}function ju(n){var t=new n.constructor(n.byteLength);return new Vn(t).set(new Vn(n)),t}function ku(n,t){var r=t?ju(n.buffer):n.buffer;return new n.constructor(r,n.byteOffset,n.length)}function Eu(n,t){if(n!==t){var r=n!==u,e=null===n,i=n===n,o=cf(n),f=t!==u,a=null===t,c=t===t,l=cf(t);if(!a&&!l&&!o&&n>t||o&&f&&c&&!a&&!l||e&&f&&c||!r&&c||!i)return 1;if(!e&&!o&&!l&&n1?r[i-1]:u,f=i>2?r[2]:u;for(o=n.length>3&&"function"==typeof o?(i--,o):u,f&&wi(r[0],r[1],f)&&(o=i<3?u:o,i=1),t=Rn(t);++e-1?i[o?t[f]:f]:u}}function $u(n){return ri((function(t){var r=t.length,e=r,o=qr.prototype.thru;for(n&&t.reverse();e--;){var f=t[e];if("function"!=typeof f)throw new zn(i);if(o&&!a&&"wrapper"==oi(f))var a=new qr([],!0)}for(e=a?e:r;++e1&&b.reverse(),p&&la))return!1;var l=o.get(n),s=o.get(t);if(l&&s)return l==t&&s==n;var h=-1,p=!0,v=2&r?new Gr:u;for(o.set(n,t),o.set(t,n);++h-1&&n%1==0&&n1?"& ":"")+t[e],t=t.join(r>2?", ":" "),n.replace(cn,"{\n/* [wrapped with "+t+"] */\n")}(e,function(n,t){return zt(y,(function(r){var e="_."+r[0];t&r[1]&&!Wt(n,e)&&n.push(e)})),n.sort()}(function(n){var t=n.match(ln);return t?t[1].split(sn):[]}(e),r)))}function Li(n){var t=0,r=0;return function(){var e=br(),i=16-(e-r);if(r=e,i>0){if(++t>=800)return arguments[0]}else t=0;return n.apply(u,arguments)}}function Wi(n,t){var r=-1,e=n.length,i=e-1;for(t=t===u?e:t;++r1?n[t-1]:u;return r="function"==typeof r?(n.pop(),r):u,uo(n,r)}));function so(n){var t=Dr(n);return t.__chain__=!0,t}function ho(n,t){return t(n)}var po=ri((function(n){var t=n.length,r=t?n[0]:0,e=this.__wrapped__,i=function(t){return oe(t,n)};return!(t>1||this.__actions__.length)&&e instanceof Pr&&di(r)?((e=e.slice(r,+r+(t?1:0))).__actions__.push({func:ho,args:[i],thisArg:u}),new qr(e,this.__chain__).thru((function(n){return t&&!n.length&&n.push(u),n}))):this.thru(i)}));var vo=Su((function(n,t,r){Tn.call(n,r)?++n[r]:ie(n,r,1)}));var _o=Mu(Fi),go=Mu(qi);function yo(n,t){return(Po(n)?zt:he)(n,ai(t,3))}function wo(n,t){return(Po(n)?St:pe)(n,ai(t,3))}var bo=Su((function(n,t,r){Tn.call(n,r)?n[r].push(t):ie(n,r,[t])}));var mo=Je((function(n,t,e){var u=-1,i="function"==typeof t,o=Zo(n)?r(n.length):[];return he(n,(function(n){o[++u]=i?Ot(t,n,e):ze(n,t,e)})),o})),xo=Su((function(n,t,r){ie(n,r,t)}));function Ao(n,t){return(Po(n)?Tt:$e)(n,ai(t,3))}var jo=Su((function(n,t,r){n[r?0:1].push(t)}),(function(){return[[],[]]}));var ko=Je((function(n,t){if(null==n)return[];var r=t.length;return r>1&&wi(n,t[0],t[1])?t=[]:r>2&&wi(t[0],t[1],t[2])&&(t=[t[0]]),Pe(n,ye(t,1),[])})),Eo=it||function(){return gt.Date.now()};function Ro(n,t,r){return t=r?u:t,t=n&&null==t?n.length:t,Yu(n,s,u,u,u,u,t)}function Oo(n,t){var r;if("function"!=typeof t)throw new zn(i);return n=_f(n),function(){return--n>0&&(r=t.apply(this,arguments)),n<=1&&(t=u),r}}var Io=Je((function(n,t,r){var e=1;if(r.length){var u=sr(r,fi(Io));e|=c}return Yu(n,e,t,r,u)})),zo=Je((function(n,t,r){var e=3;if(r.length){var u=sr(r,fi(zo));e|=c}return Yu(t,e,n,r,u)}));function So(n,t,r){var e,o,f,a,c,l,s=0,h=!1,p=!1,v=!0;if("function"!=typeof n)throw new zn(i);function _(t){var r=e,i=o;return e=o=u,s=t,a=n.apply(i,r)}function g(n){var r=n-l;return l===u||r>=t||r<0||p&&n-s>=f}function y(){var n=Eo();if(g(n))return d(n);c=zi(y,function(n){var r=t-(n-l);return p?wr(r,f-(n-s)):r}(n))}function d(n){return c=u,v&&e?_(n):(e=o=u,a)}function w(){var n=Eo(),r=g(n);if(e=arguments,o=this,l=n,r){if(c===u)return function(n){return s=n,c=zi(y,t),h?_(n):a}(l);if(p)return xu(c),c=zi(y,t),_(l)}return c===u&&(c=zi(y,t)),a}return t=yf(t)||0,nf(r)&&(h=!!r.leading,f=(p="maxWait"in r)?Ht(yf(r.maxWait)||0,t):f,v="trailing"in r?!!r.trailing:v),w.cancel=function(){c!==u&&xu(c),s=0,e=l=o=c=u},w.flush=function(){return c===u?a:d(Eo())},w}var Co=Je((function(n,t){return le(n,1,t)})),Lo=Je((function(n,t,r){return le(n,yf(t)||0,r)}));function Wo(n,t){if("function"!=typeof n||null!=t&&"function"!=typeof t)throw new zn(i);var r=function(){var e=arguments,u=t?t.apply(this,e):e[0],i=r.cache;if(i.has(u))return i.get(u);var o=n.apply(this,e);return r.cache=i.set(u,o)||i,o};return r.cache=new(Wo.Cache||Kr),r}function Bo(n){if("function"!=typeof n)throw new zn(i);return function(){var t=arguments;switch(t.length){case 0:return!n.call(this);case 1:return!n.call(this,t[0]);case 2:return!n.call(this,t[0],t[1]);case 3:return!n.call(this,t[0],t[1],t[2])}return!n.apply(this,t)}}Wo.Cache=Kr;var To=bu((function(n,t){var r=(t=1==t.length&&Po(t[0])?Tt(t[0],nr(ai())):Tt(ye(t,1),nr(ai()))).length;return Je((function(e){for(var u=-1,i=wr(e.length,r);++u=t})),qo=Se(function(){return arguments}())?Se:function(n){return tf(n)&&Tn.call(n,"callee")&&!Hn.call(n,"callee")},Po=r.isArray,Vo=xt?nr(xt):function(n){return tf(n)&&ke(n)==W};function Zo(n){return null!=n&&Xo(n.length)&&!Yo(n)}function Ko(n){return tf(n)&&Zo(n)}var Go=dt||ya,Ho=At?nr(At):function(n){return tf(n)&&ke(n)==m};function Jo(n){if(!tf(n))return!1;var t=ke(n);return t==x||"[object DOMException]"==t||"string"==typeof n.message&&"string"==typeof n.name&&!uf(n)}function Yo(n){if(!nf(n))return!1;var t=ke(n);return t==A||t==j||"[object AsyncFunction]"==t||"[object Proxy]"==t}function Qo(n){return"number"==typeof n&&n==_f(n)}function Xo(n){return"number"==typeof n&&n>-1&&n%1==0&&n<=v}function nf(n){var t=typeof n;return null!=n&&("object"==t||"function"==t)}function tf(n){return null!=n&&"object"==typeof n}var rf=jt?nr(jt):function(n){return tf(n)&&vi(n)==k};function ef(n){return"number"==typeof n||tf(n)&&ke(n)==E}function uf(n){if(!tf(n)||ke(n)!=R)return!1;var t=Kn(n);if(null===t)return!0;var r=Tn.call(t,"constructor")&&t.constructor;return"function"==typeof r&&r instanceof r&&Bn.call(r)==Dn}var of=kt?nr(kt):function(n){return tf(n)&&ke(n)==I};var ff=Et?nr(Et):function(n){return tf(n)&&vi(n)==z};function af(n){return"string"==typeof n||!Po(n)&&tf(n)&&ke(n)==S}function cf(n){return"symbol"==typeof n||tf(n)&&ke(n)==C}var lf=Rt?nr(Rt):function(n){return tf(n)&&Xo(n.length)&&!!ct[ke(n)]};var sf=Zu(Me),hf=Zu((function(n,t){return n<=t}));function pf(n){if(!n)return[];if(Zo(n))return af(n)?_r(n):Iu(n);if(Qn&&n[Qn])return function(n){for(var t,r=[];!(t=n.next()).done;)r.push(t.value);return r}(n[Qn]());var t=vi(n);return(t==k?cr:t==z?hr:Nf)(n)}function vf(n){return n?(n=yf(n))===p||n===-1/0?17976931348623157e292*(n<0?-1:1):n===n?n:0:0===n?n:0}function _f(n){var t=vf(n),r=t%1;return t===t?r?t-r:t:0}function gf(n){return n?fe(_f(n),0,g):0}function yf(n){if("number"==typeof n)return n;if(cf(n))return _;if(nf(n)){var t="function"==typeof n.valueOf?n.valueOf():n;n=nf(t)?t+"":t}if("string"!=typeof n)return 0===n?n:+n;n=Xt(n);var r=dn.test(n);return r||bn.test(n)?pt(n.slice(2),r?2:8):yn.test(n)?_:+n}function df(n){return zu(n,Lf(n))}function wf(n){return null==n?"":cu(n)}var bf=Cu((function(n,t){if(Ai(t)||Zo(t))zu(t,Cf(t),n);else for(var r in t)Tn.call(t,r)&&te(n,r,t[r])})),mf=Cu((function(n,t){zu(t,Lf(t),n)})),xf=Cu((function(n,t,r,e){zu(t,Lf(t),n,e)})),Af=Cu((function(n,t,r,e){zu(t,Cf(t),n,e)})),jf=ri(oe);var kf=Je((function(n,t){n=Rn(n);var r=-1,e=t.length,i=e>2?t[2]:u;for(i&&wi(t[0],t[1],i)&&(e=1);++r1),t})),zu(n,ui(n),r),e&&(r=ae(r,7,ni));for(var u=t.length;u--;)su(r,t[u]);return r}));var Uf=ri((function(n,t){return null==n?{}:function(n,t){return Ve(n,t,(function(t,r){return Of(n,r)}))}(n,t)}));function Mf(n,t){if(null==n)return{};var r=Tt(ui(n),(function(n){return[n]}));return t=ai(t),Ve(n,r,(function(n,r){return t(n,r[0])}))}var $f=Ju(Cf),Df=Ju(Lf);function Nf(n){return null==n?[]:tr(n,Cf(n))}var Ff=Tu((function(n,t,r){return t=t.toLowerCase(),n+(r?qf(t):t)}));function qf(n){return Yf(wf(n).toLowerCase())}function Pf(n){return(n=wf(n))&&n.replace(xn,ir).replace(rt,"")}var Vf=Tu((function(n,t,r){return n+(r?"-":"")+t.toLowerCase()})),Zf=Tu((function(n,t,r){return n+(r?" ":"")+t.toLowerCase()})),Kf=Bu("toLowerCase");var Gf=Tu((function(n,t,r){return n+(r?"_":"")+t.toLowerCase()}));var Hf=Tu((function(n,t,r){return n+(r?" ":"")+Yf(t)}));var Jf=Tu((function(n,t,r){return n+(r?" ":"")+t.toUpperCase()})),Yf=Bu("toUpperCase");function Qf(n,t,r){return n=wf(n),(t=r?u:t)===u?function(n){return ot.test(n)}(n)?function(n){return n.match(ut)||[]}(n):function(n){return n.match(hn)||[]}(n):n.match(t)||[]}var Xf=Je((function(n,t){try{return Ot(n,u,t)}catch(r){return Jo(r)?r:new an(r)}})),na=ri((function(n,t){return zt(t,(function(t){t=Ti(t),ie(n,t,Io(n[t],n))})),n}));function ta(n){return function(){return n}}var ra=$u(),ea=$u(!0);function ua(n){return n}function ia(n){return Be("function"==typeof n?n:ae(n,1))}var oa=Je((function(n,t){return function(r){return ze(r,n,t)}})),fa=Je((function(n,t){return function(r){return ze(n,r,t)}}));function aa(n,t,r){var e=Cf(t),u=xe(t,e);null!=r||nf(t)&&(u.length||!e.length)||(r=t,t=n,n=this,u=xe(t,Cf(t)));var i=!(nf(r)&&"chain"in r)||!!r.chain,o=Yo(n);return zt(u,(function(r){var e=t[r];n[r]=e,o&&(n.prototype[r]=function(){var t=this.__chain__;if(i||t){var r=n(this.__wrapped__);return(r.__actions__=Iu(this.__actions__)).push({func:e,args:arguments,thisArg:n}),r.__chain__=t,r}return e.apply(n,Ut([this.value()],arguments))})})),n}function ca(){}var la=qu(Tt),sa=qu(Ct),ha=qu(Dt);function pa(n){return bi(n)?Gt(Ti(n)):function(n){return function(t){return Ae(t,n)}}(n)}var va=Vu(),_a=Vu(!0);function ga(){return[]}function ya(){return!1}var da=Fu((function(n,t){return n+t}),0),wa=Gu("ceil"),ba=Fu((function(n,t){return n/t}),1),ma=Gu("floor");var xa=Fu((function(n,t){return n*t}),1),Aa=Gu("round"),ja=Fu((function(n,t){return n-t}),0);return Dr.after=function(n,t){if("function"!=typeof t)throw new zn(i);return n=_f(n),function(){if(--n<1)return t.apply(this,arguments)}},Dr.ary=Ro,Dr.assign=bf,Dr.assignIn=mf,Dr.assignInWith=xf,Dr.assignWith=Af,Dr.at=jf,Dr.before=Oo,Dr.bind=Io,Dr.bindAll=na,Dr.bindKey=zo,Dr.castArray=function(){if(!arguments.length)return[];var n=arguments[0];return Po(n)?n:[n]},Dr.chain=so,Dr.chunk=function(n,t,e){t=(e?wi(n,t,e):t===u)?1:Ht(_f(t),0);var i=null==n?0:n.length;if(!i||t<1)return[];for(var o=0,f=0,a=r(vt(i/t));oi?0:i+r),(e=e===u||e>i?i:_f(e))<0&&(e+=i),e=r>e?0:gf(e);r>>0)?(n=wf(n))&&("string"==typeof t||null!=t&&!of(t))&&!(t=cu(t))&&ar(n)?mu(_r(n),0,r):n.split(t,r):[]},Dr.spread=function(n,t){if("function"!=typeof n)throw new zn(i);return t=null==t?0:Ht(_f(t),0),Je((function(r){var e=r[t],u=mu(r,0,t);return e&&Ut(u,e),Ot(n,this,u)}))},Dr.tail=function(n){var t=null==n?0:n.length;return t?eu(n,1,t):[]},Dr.take=function(n,t,r){return n&&n.length?eu(n,0,(t=r||t===u?1:_f(t))<0?0:t):[]},Dr.takeRight=function(n,t,r){var e=null==n?0:n.length;return e?eu(n,(t=e-(t=r||t===u?1:_f(t)))<0?0:t,e):[]},Dr.takeRightWhile=function(n,t){return n&&n.length?pu(n,ai(t,3),!1,!0):[]},Dr.takeWhile=function(n,t){return n&&n.length?pu(n,ai(t,3)):[]},Dr.tap=function(n,t){return t(n),n},Dr.throttle=function(n,t,r){var e=!0,u=!0;if("function"!=typeof n)throw new zn(i);return nf(r)&&(e="leading"in r?!!r.leading:e,u="trailing"in r?!!r.trailing:u),So(n,t,{leading:e,maxWait:t,trailing:u})},Dr.thru=ho,Dr.toArray=pf,Dr.toPairs=$f,Dr.toPairsIn=Df,Dr.toPath=function(n){return Po(n)?Tt(n,Ti):cf(n)?[n]:Iu(Bi(wf(n)))},Dr.toPlainObject=df,Dr.transform=function(n,t,r){var e=Po(n),u=e||Go(n)||lf(n);if(t=ai(t,4),null==r){var i=n&&n.constructor;r=u?e?new i:[]:nf(n)&&Yo(i)?Nr(Kn(n)):{}}return(u?zt:be)(n,(function(n,e,u){return t(r,n,e,u)})),r},Dr.unary=function(n){return Ro(n,1)},Dr.union=no,Dr.unionBy=to,Dr.unionWith=ro,Dr.uniq=function(n){return n&&n.length?lu(n):[]},Dr.uniqBy=function(n,t){return n&&n.length?lu(n,ai(t,2)):[]},Dr.uniqWith=function(n,t){return t="function"==typeof t?t:u,n&&n.length?lu(n,u,t):[]},Dr.unset=function(n,t){return null==n||su(n,t)},Dr.unzip=eo,Dr.unzipWith=uo,Dr.update=function(n,t,r){return null==n?n:hu(n,t,du(r))},Dr.updateWith=function(n,t,r,e){return e="function"==typeof e?e:u,null==n?n:hu(n,t,du(r),e)},Dr.values=Nf,Dr.valuesIn=function(n){return null==n?[]:tr(n,Lf(n))},Dr.without=io,Dr.words=Qf,Dr.wrap=function(n,t){return Uo(du(t),n)},Dr.xor=oo,Dr.xorBy=fo,Dr.xorWith=ao,Dr.zip=co,Dr.zipObject=function(n,t){return gu(n||[],t||[],te)},Dr.zipObjectDeep=function(n,t){return gu(n||[],t||[],Xe)},Dr.zipWith=lo,Dr.entries=$f,Dr.entriesIn=Df,Dr.extend=mf,Dr.extendWith=xf,aa(Dr,Dr),Dr.add=da,Dr.attempt=Xf,Dr.camelCase=Ff,Dr.capitalize=qf,Dr.ceil=wa,Dr.clamp=function(n,t,r){return r===u&&(r=t,t=u),r!==u&&(r=(r=yf(r))===r?r:0),t!==u&&(t=(t=yf(t))===t?t:0),fe(yf(n),t,r)},Dr.clone=function(n){return ae(n,4)},Dr.cloneDeep=function(n){return ae(n,5)},Dr.cloneDeepWith=function(n,t){return ae(n,5,t="function"==typeof t?t:u)},Dr.cloneWith=function(n,t){return ae(n,4,t="function"==typeof t?t:u)},Dr.conformsTo=function(n,t){return null==t||ce(n,t,Cf(t))},Dr.deburr=Pf,Dr.defaultTo=function(n,t){return null==n||n!==n?t:n},Dr.divide=ba,Dr.endsWith=function(n,t,r){n=wf(n),t=cu(t);var e=n.length,i=r=r===u?e:fe(_f(r),0,e);return(r-=t.length)>=0&&n.slice(r,i)==t},Dr.eq=Do,Dr.escape=function(n){return(n=wf(n))&&Y.test(n)?n.replace(H,or):n},Dr.escapeRegExp=function(n){return(n=wf(n))&&on.test(n)?n.replace(un,"\\$&"):n},Dr.every=function(n,t,r){var e=Po(n)?Ct:ve;return r&&wi(n,t,r)&&(t=u),e(n,ai(t,3))},Dr.find=_o,Dr.findIndex=Fi,Dr.findKey=function(n,t){return Ft(n,ai(t,3),be)},Dr.findLast=go,Dr.findLastIndex=qi,Dr.findLastKey=function(n,t){return Ft(n,ai(t,3),me)},Dr.floor=ma,Dr.forEach=yo,Dr.forEachRight=wo,Dr.forIn=function(n,t){return null==n?n:de(n,ai(t,3),Lf)},Dr.forInRight=function(n,t){return null==n?n:we(n,ai(t,3),Lf)},Dr.forOwn=function(n,t){return n&&be(n,ai(t,3))},Dr.forOwnRight=function(n,t){return n&&me(n,ai(t,3))},Dr.get=Rf,Dr.gt=No,Dr.gte=Fo,Dr.has=function(n,t){return null!=n&&_i(n,t,Re)},Dr.hasIn=Of,Dr.head=Vi,Dr.identity=ua,Dr.includes=function(n,t,r,e){n=Zo(n)?n:Nf(n),r=r&&!e?_f(r):0;var u=n.length;return r<0&&(r=Ht(u+r,0)),af(n)?r<=u&&n.indexOf(t,r)>-1:!!u&&Pt(n,t,r)>-1},Dr.indexOf=function(n,t,r){var e=null==n?0:n.length;if(!e)return-1;var u=null==r?0:_f(r);return u<0&&(u=Ht(e+u,0)),Pt(n,t,u)},Dr.inRange=function(n,t,r){return t=vf(t),r===u?(r=t,t=0):r=vf(r),function(n,t,r){return n>=wr(t,r)&&n=-9007199254740991&&n<=v},Dr.isSet=ff,Dr.isString=af,Dr.isSymbol=cf,Dr.isTypedArray=lf,Dr.isUndefined=function(n){return n===u},Dr.isWeakMap=function(n){return tf(n)&&vi(n)==L},Dr.isWeakSet=function(n){return tf(n)&&"[object WeakSet]"==ke(n)},Dr.join=function(n,t){return null==n?"":mt.call(n,t)},Dr.kebabCase=Vf,Dr.last=Hi,Dr.lastIndexOf=function(n,t,r){var e=null==n?0:n.length;if(!e)return-1;var i=e;return r!==u&&(i=(i=_f(r))<0?Ht(e+i,0):wr(i,e-1)),t===t?function(n,t,r){for(var e=r+1;e--;)if(n[e]===t)return e;return e}(n,t,i):qt(n,Zt,i,!0)},Dr.lowerCase=Zf,Dr.lowerFirst=Kf,Dr.lt=sf,Dr.lte=hf,Dr.max=function(n){return n&&n.length?_e(n,ua,Ee):u},Dr.maxBy=function(n,t){return n&&n.length?_e(n,ai(t,2),Ee):u},Dr.mean=function(n){return Kt(n,ua)},Dr.meanBy=function(n,t){return Kt(n,ai(t,2))},Dr.min=function(n){return n&&n.length?_e(n,ua,Me):u},Dr.minBy=function(n,t){return n&&n.length?_e(n,ai(t,2),Me):u},Dr.stubArray=ga,Dr.stubFalse=ya,Dr.stubObject=function(){return{}},Dr.stubString=function(){return""},Dr.stubTrue=function(){return!0},Dr.multiply=xa,Dr.nth=function(n,t){return n&&n.length?qe(n,_f(t)):u},Dr.noConflict=function(){return gt._===this&&(gt._=Nn),this},Dr.noop=ca,Dr.now=Eo,Dr.pad=function(n,t,r){n=wf(n);var e=(t=_f(t))?vr(n):0;if(!t||e>=t)return n;var u=(t-e)/2;return Pu(_t(u),r)+n+Pu(vt(u),r)},Dr.padEnd=function(n,t,r){n=wf(n);var e=(t=_f(t))?vr(n):0;return t&&et){var e=n;n=t,t=e}if(r||n%1||t%1){var i=xr();return wr(n+i*(t-n+ht("1e-"+((i+"").length-1))),t)}return Ge(n,t)},Dr.reduce=function(n,t,r){var e=Po(n)?Mt:Jt,u=arguments.length<3;return e(n,ai(t,4),r,u,he)},Dr.reduceRight=function(n,t,r){var e=Po(n)?$t:Jt,u=arguments.length<3;return e(n,ai(t,4),r,u,pe)},Dr.repeat=function(n,t,r){return t=(r?wi(n,t,r):t===u)?1:_f(t),He(wf(n),t)},Dr.replace=function(){var n=arguments,t=wf(n[0]);return n.length<3?t:t.replace(n[1],n[2])},Dr.result=function(n,t,r){var e=-1,i=(t=wu(t,n)).length;for(i||(i=1,n=u);++ev)return[];var r=g,e=wr(n,g);t=ai(t),n-=g;for(var u=Qt(e,t);++r=o)return n;var a=r-vr(e);if(a<1)return e;var c=f?mu(f,0,a).join(""):n.slice(0,a);if(i===u)return c+e;if(f&&(a+=c.length-a),of(i)){if(n.slice(a).search(i)){var l,s=c;for(i.global||(i=On(i.source,wf(gn.exec(i))+"g")),i.lastIndex=0;l=i.exec(s);)var h=l.index;c=c.slice(0,h===u?a:h)}}else if(n.indexOf(cu(i),a)!=a){var p=c.lastIndexOf(i);p>-1&&(c=c.slice(0,p))}return c+e},Dr.unescape=function(n){return(n=wf(n))&&J.test(n)?n.replace(G,yr):n},Dr.uniqueId=function(n){var t=++Un;return wf(n)+t},Dr.upperCase=Jf,Dr.upperFirst=Yf,Dr.each=yo,Dr.eachRight=wo,Dr.first=Vi,aa(Dr,function(){var n={};return be(Dr,(function(t,r){Tn.call(Dr.prototype,r)||(n[r]=t)})),n}(),{chain:!1}),Dr.VERSION="4.17.21",zt(["bind","bindKey","curry","curryRight","partial","partialRight"],(function(n){Dr[n].placeholder=Dr})),zt(["drop","take"],(function(n,t){Pr.prototype[n]=function(r){r=r===u?1:Ht(_f(r),0);var e=this.__filtered__&&!t?new Pr(this):this.clone();return e.__filtered__?e.__takeCount__=wr(r,e.__takeCount__):e.__views__.push({size:wr(r,g),type:n+(e.__dir__<0?"Right":"")}),e},Pr.prototype[n+"Right"]=function(t){return this.reverse()[n](t).reverse()}})),zt(["filter","map","takeWhile"],(function(n,t){var r=t+1,e=1==r||3==r;Pr.prototype[n]=function(n){var t=this.clone();return t.__iteratees__.push({iteratee:ai(n,3),type:r}),t.__filtered__=t.__filtered__||e,t}})),zt(["head","last"],(function(n,t){var r="take"+(t?"Right":"");Pr.prototype[n]=function(){return this[r](1).value()[0]}})),zt(["initial","tail"],(function(n,t){var r="drop"+(t?"":"Right");Pr.prototype[n]=function(){return this.__filtered__?new Pr(this):this[r](1)}})),Pr.prototype.compact=function(){return this.filter(ua)},Pr.prototype.find=function(n){return this.filter(n).head()},Pr.prototype.findLast=function(n){return this.reverse().find(n)},Pr.prototype.invokeMap=Je((function(n,t){return"function"==typeof n?new Pr(this):this.map((function(r){return ze(r,n,t)}))})),Pr.prototype.reject=function(n){return this.filter(Bo(ai(n)))},Pr.prototype.slice=function(n,t){n=_f(n);var r=this;return r.__filtered__&&(n>0||t<0)?new Pr(r):(n<0?r=r.takeRight(-n):n&&(r=r.drop(n)),t!==u&&(r=(t=_f(t))<0?r.dropRight(-t):r.take(t-n)),r)},Pr.prototype.takeRightWhile=function(n){return this.reverse().takeWhile(n).reverse()},Pr.prototype.toArray=function(){return this.take(g)},be(Pr.prototype,(function(n,t){var r=/^(?:filter|find|map|reject)|While$/.test(t),e=/^(?:head|last)$/.test(t),i=Dr[e?"take"+("last"==t?"Right":""):t],o=e||/^find/.test(t);i&&(Dr.prototype[t]=function(){var t=this.__wrapped__,f=e?[1]:arguments,a=t instanceof Pr,c=f[0],l=a||Po(t),s=function(n){var t=i.apply(Dr,Ut([n],f));return e&&h?t[0]:t};l&&r&&"function"==typeof c&&1!=c.length&&(a=l=!1);var h=this.__chain__,p=!!this.__actions__.length,v=o&&!h,_=a&&!p;if(!o&&l){t=_?t:new Pr(this);var g=n.apply(t,f);return g.__actions__.push({func:ho,args:[s],thisArg:u}),new qr(g,h)}return v&&_?n.apply(this,f):(g=this.thru(s),v?e?g.value()[0]:g.value():g)})})),zt(["pop","push","shift","sort","splice","unshift"],(function(n){var t=Sn[n],r=/^(?:push|sort|unshift)$/.test(n)?"tap":"thru",e=/^(?:pop|shift)$/.test(n);Dr.prototype[n]=function(){var n=arguments;if(e&&!this.__chain__){var u=this.value();return t.apply(Po(u)?u:[],n)}return this[r]((function(r){return t.apply(Po(r)?r:[],n)}))}})),be(Pr.prototype,(function(n,t){var r=Dr[t];if(r){var e=r.name+"";Tn.call(Sr,e)||(Sr[e]=[]),Sr[e].push({name:t,func:r})}})),Sr[Du(u,2).name]=[{name:"wrapper",func:u}],Pr.prototype.clone=function(){var n=new Pr(this.__wrapped__);return n.__actions__=Iu(this.__actions__),n.__dir__=this.__dir__,n.__filtered__=this.__filtered__,n.__iteratees__=Iu(this.__iteratees__),n.__takeCount__=this.__takeCount__,n.__views__=Iu(this.__views__),n},Pr.prototype.reverse=function(){if(this.__filtered__){var n=new Pr(this);n.__dir__=-1,n.__filtered__=!0}else(n=this.clone()).__dir__*=-1;return n},Pr.prototype.value=function(){var n=this.__wrapped__.value(),t=this.__dir__,r=Po(n),e=t<0,u=r?n.length:0,i=function(n,t,r){var e=-1,u=r.length;for(;++e=this.__values__.length;return{done:n,value:n?u:this.__values__[this.__index__++]}},Dr.prototype.plant=function(n){for(var t,r=this;r instanceof Fr;){var e=Mi(r);e.__index__=0,e.__values__=u,t?i.__wrapped__=e:t=e;var i=e;r=r.__wrapped__}return i.__wrapped__=n,t},Dr.prototype.reverse=function(){var n=this.__wrapped__;if(n instanceof Pr){var t=n;return this.__actions__.length&&(t=new Pr(this)),(t=t.reverse()).__actions__.push({func:ho,args:[Xi],thisArg:u}),new qr(t,this.__chain__)}return this.thru(Xi)},Dr.prototype.toJSON=Dr.prototype.valueOf=Dr.prototype.value=function(){return vu(this.__wrapped__,this.__actions__)},Dr.prototype.first=Dr.prototype.head,Qn&&(Dr.prototype[Qn]=function(){return this}),Dr}();gt._=dr,(e=function(){return dr}.call(t,r,t,n))===u||(n.exports=e)}.call(this)}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4872.2eea7e0a.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/4872.2eea7e0a.chunk.js.LICENSE.txt deleted file mode 100644 index b1121f519abf..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4872.2eea7e0a.chunk.js.LICENSE.txt +++ /dev/null @@ -1,8 +0,0 @@ -/** - * @license - * Lodash - * Copyright OpenJS Foundation and other contributors - * Released under MIT license - * Based on Underscore.js 1.8.3 - * Copyright Jeremy Ashkenas, DocumentCloud and Investigative Reporters & Editors - */ diff --git a/ydb/core/viewer/monitoring/static/js/4887.f016c3bb.chunk.js b/ydb/core/viewer/monitoring/static/js/4887.f016c3bb.chunk.js new file mode 100644 index 000000000000..8e6baa829f3c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/4887.f016c3bb.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4887],{4887:(e,t,a)=>{a.d(t,{default:()=>o});var n=a(99546);const o=a.n(n)()},99546:e=>{function t(e){e.languages.moonscript={comment:/--.*/,string:[{pattern:/'[^']*'|\[(=*)\[[\s\S]*?\]\1\]/,greedy:!0},{pattern:/"[^"]*"/,greedy:!0,inside:{interpolation:{pattern:/#\{[^{}]*\}/,inside:{moonscript:{pattern:/(^#\{)[\s\S]+(?=\})/,lookbehind:!0,inside:null},"interpolation-punctuation":{pattern:/#\{|\}/,alias:"punctuation"}}}}}],"class-name":[{pattern:/(\b(?:class|extends)[ \t]+)\w+/,lookbehind:!0},/\b[A-Z]\w*/],keyword:/\b(?:class|continue|do|else|elseif|export|extends|for|from|if|import|in|local|nil|return|self|super|switch|then|unless|using|when|while|with)\b/,variable:/@@?\w*/,property:{pattern:/\b(?!\d)\w+(?=:)|(:)(?!\d)\w+/,lookbehind:!0},function:{pattern:/\b(?:_G|_VERSION|assert|collectgarbage|coroutine\.(?:create|resume|running|status|wrap|yield)|debug\.(?:debug|getfenv|gethook|getinfo|getlocal|getmetatable|getregistry|getupvalue|setfenv|sethook|setlocal|setmetatable|setupvalue|traceback)|dofile|error|getfenv|getmetatable|io\.(?:close|flush|input|lines|open|output|popen|read|stderr|stdin|stdout|tmpfile|type|write)|ipairs|load|loadfile|loadstring|math\.(?:abs|acos|asin|atan|atan2|ceil|cos|cosh|deg|exp|floor|fmod|frexp|ldexp|log|log10|max|min|modf|pi|pow|rad|random|randomseed|sin|sinh|sqrt|tan|tanh)|module|next|os\.(?:clock|date|difftime|execute|exit|getenv|remove|rename|setlocale|time|tmpname)|package\.(?:cpath|loaded|loadlib|path|preload|seeall)|pairs|pcall|print|rawequal|rawget|rawset|require|select|setfenv|setmetatable|string\.(?:byte|char|dump|find|format|gmatch|gsub|len|lower|match|rep|reverse|sub|upper)|table\.(?:concat|insert|maxn|remove|sort)|tonumber|tostring|type|unpack|xpcall)\b/,inside:{punctuation:/\./}},boolean:/\b(?:false|true)\b/,number:/(?:\B\.\d+|\b\d+\.\d+|\b\d+(?=[eE]))(?:[eE][-+]?\d+)?\b|\b(?:0x[a-fA-F\d]+|\d+)(?:U?LL)?\b/,operator:/\.{3}|[-=]>|~=|(?:[-+*/%<>!=]|\.\.)=?|[:#^]|\b(?:and|or)\b=?|\b(?:not)\b/,punctuation:/[.,()[\]{}\\]/},e.languages.moonscript.string[1].inside.interpolation.inside.moonscript.inside=e.languages.moonscript,e.languages.moon=e.languages.moonscript}e.exports=t,t.displayName="moonscript",t.aliases=["moon"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4891.c441be74.chunk.js b/ydb/core/viewer/monitoring/static/js/4891.c441be74.chunk.js deleted file mode 100644 index 842e4f3557fc..000000000000 --- a/ydb/core/viewer/monitoring/static/js/4891.c441be74.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[4891],{74891:function(a,e,_){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var _=e(a),i={name:"sw",weekdays:"Jumapili_Jumatatu_Jumanne_Jumatano_Alhamisi_Ijumaa_Jumamosi".split("_"),weekdaysShort:"Jpl_Jtat_Jnne_Jtan_Alh_Ijm_Jmos".split("_"),weekdaysMin:"J2_J3_J4_J5_Al_Ij_J1".split("_"),months:"Januari_Februari_Machi_Aprili_Mei_Juni_Julai_Agosti_Septemba_Oktoba_Novemba_Desemba".split("_"),monthsShort:"Jan_Feb_Mac_Apr_Mei_Jun_Jul_Ago_Sep_Okt_Nov_Des".split("_"),weekStart:1,ordinal:function(a){return a},relativeTime:{future:"%s baadaye",past:"tokea %s",s:"hivi punde",m:"dakika moja",mm:"dakika %d",h:"saa limoja",hh:"masaa %d",d:"siku moja",dd:"masiku %d",M:"mwezi mmoja",MM:"miezi %d",y:"mwaka mmoja",yy:"miaka %d"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"}};return _.default.locale(i,null,!0),i}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/48914.0bb2f1c2.chunk.js b/ydb/core/viewer/monitoring/static/js/48914.0bb2f1c2.chunk.js new file mode 100644 index 000000000000..b16d9fe6e69c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/48914.0bb2f1c2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[48914],{48914:(e,n,a)=>{a.d(n,{default:()=>i});var t=a(96347);const i=a.n(t)()},96347:e=>{function n(e){!function(e){e.languages.velocity=e.languages.extend("markup",{});var n={variable:{pattern:/(^|[^\\](?:\\\\)*)\$!?(?:[a-z][\w-]*(?:\([^)]*\))?(?:\.[a-z][\w-]*(?:\([^)]*\))?|\[[^\]]+\])*|\{[^}]+\})/i,lookbehind:!0,inside:{}},string:{pattern:/"[^"]*"|'[^']*'/,greedy:!0},number:/\b\d+\b/,boolean:/\b(?:false|true)\b/,operator:/[=!<>]=?|[+*/%-]|&&|\|\||\.\.|\b(?:eq|g[et]|l[et]|n(?:e|ot))\b/,punctuation:/[(){}[\]:,.]/};n.variable.inside={string:n.string,function:{pattern:/([^\w-])[a-z][\w-]*(?=\()/,lookbehind:!0},number:n.number,boolean:n.boolean,punctuation:n.punctuation},e.languages.insertBefore("velocity","comment",{unparsed:{pattern:/(^|[^\\])#\[\[[\s\S]*?\]\]#/,lookbehind:!0,greedy:!0,inside:{punctuation:/^#\[\[|\]\]#$/}},"velocity-comment":[{pattern:/(^|[^\\])#\*[\s\S]*?\*#/,lookbehind:!0,greedy:!0,alias:"comment"},{pattern:/(^|[^\\])##.*/,lookbehind:!0,greedy:!0,alias:"comment"}],directive:{pattern:/(^|[^\\](?:\\\\)*)#@?(?:[a-z][\w-]*|\{[a-z][\w-]*\})(?:\s*\((?:[^()]|\([^()]*\))*\))?/i,lookbehind:!0,inside:{keyword:{pattern:/^#@?(?:[a-z][\w-]*|\{[a-z][\w-]*\})|\bin\b/,inside:{punctuation:/[{}]/}},rest:n}},variable:n.variable}),e.languages.velocity.tag.inside["attr-value"].inside.rest=e.languages.velocity}(e)}e.exports=n,n.displayName="velocity",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/49067.2e09b756.chunk.js b/ydb/core/viewer/monitoring/static/js/49067.2e09b756.chunk.js new file mode 100644 index 000000000000..01940a7c6440 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49067.2e09b756.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49067],{49067:function(a,e,i){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var i=e(a),_={name:"mi",weekdays:"R\u0101tapu_Mane_T\u016brei_Wenerei_T\u0101ite_Paraire_H\u0101tarei".split("_"),months:"Kohi-t\u0101te_Hui-tanguru_Pout\u016b-te-rangi_Paenga-wh\u0101wh\u0101_Haratua_Pipiri_H\u014dngoingoi_Here-turi-k\u014dk\u0101_Mahuru_Whiringa-\u0101-nuku_Whiringa-\u0101-rangi_Hakihea".split("_"),weekStart:1,weekdaysShort:"Ta_Ma_T\u016b_We_T\u0101i_Pa_H\u0101".split("_"),monthsShort:"Kohi_Hui_Pou_Pae_Hara_Pipi_H\u014dngoi_Here_Mahu_Whi-nu_Whi-ra_Haki".split("_"),weekdaysMin:"Ta_Ma_T\u016b_We_T\u0101i_Pa_H\u0101".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [i] HH:mm",LLLL:"dddd, D MMMM YYYY [i] HH:mm"},relativeTime:{future:"i roto i %s",past:"%s i mua",s:"te h\u0113kona ruarua",m:"he meneti",mm:"%d meneti",h:"te haora",hh:"%d haora",d:"he ra",dd:"%d ra",M:"he marama",MM:"%d marama",y:"he tau",yy:"%d tau"}};return i.default.locale(_,null,!0),_}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/49393.521eb7df.chunk.js b/ydb/core/viewer/monitoring/static/js/49393.521eb7df.chunk.js new file mode 100644 index 000000000000..d1883f8fe711 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49393.521eb7df.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49393],{3685:(e,t,a)=>{a.d(t,{$:()=>i});var n=a(54090),l=a(77506),s=a(33775),o=a(60712);const r=(0,l.cn)("ydb-entity-page-title");function i({entityName:e,status:t=n.m.Grey,id:a,className:l}){return(0,o.jsxs)("div",{className:r(null,l),children:[(0,o.jsx)("span",{className:r("prefix"),children:e}),(0,o.jsx)(s.k,{className:r("icon"),status:t,size:"s"}),a]})}},21545:(e,t,a)=>{a.d(t,{X:()=>l});var n=a(78034);const l=a(21334).F.injectEndpoints({endpoints:e=>({getTablet:e.query({queryFn:async({id:e,database:t,followerId:a},{signal:l})=>{try{const[s,o,r]=await Promise.all([window.api.viewer.getTablet({id:e,database:t,followerId:a},{signal:l}),window.api.viewer.getTabletHistory({id:e,database:t},{signal:l}),window.api.viewer.getNodesList({signal:l})]),i=(0,n.nN)(r),d=Object.keys(o).reduce(((e,t)=>{var a;const n=null===(a=o[t])||void 0===a?void 0:a.TabletStateInfo;return null===n||void 0===n||n.forEach((a=>{var n;const{ChangeTime:l,Generation:s,State:o,Leader:r,FollowerId:d}=a,c=i&&t?null===(n=i.get(Number(t)))||void 0===n?void 0:n.Host:void 0;e.push({nodeId:t,generation:s,changeTime:l,state:o,leader:r,followerId:d,fqdn:c})})),e}),[]),{TabletStateInfo:c=[]}=s,u=void 0===a?c.find((e=>e.Leader)):c.find((e=>{var t;return(null===(t=e.FollowerId)||void 0===t?void 0:t.toString())===a})),{TabletId:h}=u||{};return{data:{id:h,data:u,history:d}}}catch(s){return{error:s}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),getTabletDescribe:e.query({queryFn:async({tenantId:e},{signal:t})=>{try{const a=await window.api.viewer.getTabletDescribe(e,{signal:t}),{SchemeShard:n,PathId:l}=e;return{data:(null===a||void 0===a?void 0:a.Path)||`${n}:${l}`}}catch(a){return{error:a}}},providesTags:["All"]}),getAdvancedTableInfo:e.query({queryFn:async({id:e,hiveId:t},{signal:a})=>{try{return{data:await window.api.tablets.getTabletFromHive({id:e,hiveId:t},{signal:a})}}catch(n){return{error:n}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),killTablet:e.mutation({queryFn:async({id:e})=>{try{return{data:await window.api.tablets.killTablet(e)}}catch(t){return{error:t}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),stopTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.stopTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),resumeTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.resumeTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"})},22983:(e,t,a)=>{a.d(t,{B:()=>d});var n=a(59284),l=a(84476),s=a(84375),o=a(55974),r=a(42829),i=a(60712);function d({children:e,onConfirmAction:t,onConfirmActionSuccess:a,dialogHeader:d,dialogText:c,retryButtonText:u,buttonDisabled:h=!1,buttonView:m="action",buttonTitle:v,buttonClassName:p,withPopover:b=!1,popoverContent:g,popoverPlacement:x="right",popoverDisabled:f=!0}){const[y,w]=n.useState(!1),[j,N]=n.useState(!1),[I,T]=n.useState(!1),S=()=>(0,i.jsx)(l.$,{onClick:()=>w(!0),view:m,disabled:h,loading:!h&&j,className:p,title:v,children:e});return(0,i.jsxs)(n.Fragment,{children:[(0,i.jsx)(o.g,{visible:y,header:d,text:c,withRetry:I,retryButtonText:u,onConfirm:async e=>{N(!0),await t(e)},onConfirmActionSuccess:async()=>{T(!1);try{await(null===a||void 0===a?void 0:a())}finally{N(!1)}},onConfirmActionError:e=>{T((0,r.D)(e)),N(!1)},onClose:()=>{w(!1)}}),b?(0,i.jsx)(s.A,{content:g,placement:x,disabled:f,children:S()}):S()]})}},27775:(e,t,a)=>{a.d(t,{i:()=>o});var n=a(47665),l=a(58267),s=a(60712);function o({state:e}){return(0,s.jsx)(n.J,{theme:(0,l._)(e),children:e})}},42829:(e,t,a)=>{a.d(t,{D:()=>n});const n=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},55974:(e,t,a)=>{a.d(t,{g:()=>x});var n=a(59284),l=a(18677),s=a(71153),o=a(74321),r=a(2198),i=a(99991),d=a(56999),c=a(77506),u=a(81288),h=a(48372);const m=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),v=(0,h.g4)("ydb-critical-action-dialog",{en:m});var p=a(60712);const b=(0,c.cn)("ydb-critical-dialog"),g=e=>{if((0,u.cH)(e)){if(403===e.status)return v("no-rights-error");if("string"===typeof e.data)return e.data;if((0,u._E)(e)&&e.data)return(0,p.jsx)(d.O,{hideSeverity:!0,data:e.data});if(e.statusText)return e.statusText}return v("default-error")};function x({visible:e,header:t,text:a,withRetry:d,retryButtonText:c,withCheckBox:u,onClose:h,onConfirm:m,onConfirmActionSuccess:x,onConfirmActionError:f}){const[y,w]=n.useState(!1),[j,N]=n.useState(),[I,T]=n.useState(!1),S=async e=>(w(!0),m(e).then((()=>{x(),h()})).catch((e=>{f(e),N(e)})).finally((()=>{w(!1)})));return(0,p.jsx)(r.l,{open:e,hasCloseButton:!1,className:b(),size:"s",onClose:h,onTransitionExited:()=>{N(void 0),T(!1)},children:j?(0,p.jsxs)(n.Fragment,{children:[(0,p.jsx)(r.l.Header,{caption:t}),(0,p.jsx)(r.l.Body,{className:b("body"),children:(0,p.jsxs)("div",{className:b("body-message",{error:!0}),children:[(0,p.jsx)("span",{className:b("error-icon"),children:(0,p.jsx)(l.A,{width:"24",height:"22"})}),g(j)]})}),(0,p.jsx)(r.l.Footer,{loading:!1,preset:"default",textButtonApply:d?c||v("button-retry"):void 0,textButtonCancel:v("button-close"),onClickButtonApply:()=>S(!0),onClickButtonCancel:h})]}):(0,p.jsxs)(n.Fragment,{children:[(0,p.jsx)(r.l.Header,{caption:t}),(0,p.jsxs)(r.l.Body,{className:b("body"),children:[(0,p.jsxs)("div",{className:b("body-message",{warning:!0}),children:[(0,p.jsx)("span",{className:b("warning-icon"),children:(0,p.jsx)(i.I,{data:s.A,size:24})}),a]}),u?(0,p.jsx)(o.S,{checked:I,onUpdate:T,children:v("checkbox-text")}):null]}),(0,p.jsx)(r.l.Footer,{loading:y,preset:"default",textButtonApply:v("button-confirm"),textButtonCancel:v("button-cancel"),propsButtonApply:{type:"submit",disabled:u&&!I},onClickButtonCancel:h,onClickButtonApply:()=>S()})]})})}},56999:(e,t,a)=>{a.d(t,{O:()=>w});var n=a(59284),l=a(45720),s=a(16929),o=a(71153),r=a(18677),i=a(84476),d=a(33705),c=a(67884),u=a(99991),h=a(74529),m=a(77506),v=a(41650);const p=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function b(e){return function(e){return!!e&&void 0!==p[e]}(e)?p[e]:"S_INFO"}var g=a(60712);const x=(0,m.cn)("kv-result-issues"),f=(0,m.cn)("kv-issues"),y=(0,m.cn)("kv-issue");function w({data:e,hideSeverity:t}){const[a,l]=n.useState(!1),s="string"===typeof e||null===e||void 0===e?void 0:e.issues,o=Array.isArray(s)&&s.length>0;return(0,g.jsxs)("div",{className:x(),children:[(0,g.jsxs)("div",{className:x("error-message"),children:[(()=>{let a;if("string"===typeof e)a=e;else{var l,s;const o=b(null===e||void 0===e||null===(l=e.error)||void 0===l?void 0:l.severity);a=(0,g.jsxs)(n.Fragment,{children:[t?null:(0,g.jsxs)(n.Fragment,{children:[(0,g.jsx)(C,{severity:o})," "]}),(0,g.jsx)("span",{className:x("error-message-text"),children:null===e||void 0===e||null===(s=e.error)||void 0===s?void 0:s.message})]})}return a})(),o&&(0,g.jsx)(i.$,{view:"normal",onClick:()=>l(!a),children:a?"Hide details":"Show details"})]}),o&&a&&(0,g.jsx)(j,{hideSeverity:t,issues:s})]})}function j({issues:e,hideSeverity:t}){const a=null===e||void 0===e?void 0:e.reduce(((e,t)=>{var a;const n=null!==(a=t.severity)&&void 0!==a?a:10;return Math.min(e,n)}),10);return(0,g.jsx)("div",{className:f(null),children:null===e||void 0===e?void 0:e.map(((e,n)=>(0,g.jsx)(N,{hideSeverity:t,issue:e,expanded:e===a},n)))})}function N({issue:e,hideSeverity:t,level:a=0}){const[l,s]=n.useState(!0),o=b(e.severity),r=e.issues,c=Array.isArray(r)&&r.length>0,u=l?"bottom":"right";return(0,g.jsxs)("div",{className:y({leaf:!c,"has-issues":c}),children:[(0,g.jsxs)("div",{className:y("line"),children:[c&&(0,g.jsx)(i.$,{view:"flat-secondary",onClick:()=>s(!l),className:y("arrow-toggle"),children:(0,g.jsx)(d.I,{direction:u,size:16})}),t?null:(0,g.jsx)(C,{severity:o}),(0,g.jsx)(I,{issue:e}),e.issue_code?(0,g.jsxs)("span",{className:y("code"),children:["Code: ",e.issue_code]}):null]}),c&&l&&(0,g.jsx)("div",{className:y("issues"),children:(0,g.jsx)(T,{issues:r,level:a+1,expanded:l})})]})}function I({issue:e}){var t;const a=function(e){const{position:t}=e;if("object"!==typeof t||null===t||!(0,v.kf)(t.row))return"";const{row:a,column:n}=t;return(0,v.kf)(n)?`${a}:${n}`:`line ${a}`}(e),n=window.ydbEditor,l=()=>(0,g.jsxs)("span",{className:y("message"),children:[a&&(0,g.jsx)("span",{className:y("place-text"),title:"Position",children:a}),(0,g.jsx)("div",{className:y("message-text"),children:(0,g.jsx)(h.A,{value:e.message,expandLabel:"Show full message"})})]}),{row:s,column:o}=null!==(t=e.position)&&void 0!==t?t:{};if(!((0,v.kf)(s)&&n))return l();return(0,g.jsx)(c.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:s,column:null!==o&&void 0!==o?o:0};n.setPosition(e),n.revealPositionInCenterIfOutsideViewport(e),n.focus()},view:"primary",children:l()})}function T(e){const{issues:t,level:a,expanded:n}=e;return(0,g.jsx)("div",{className:y("list"),children:t.map(((e,t)=>(0,g.jsx)(N,{issue:e,level:a,expanded:n},t)))})}const S={S_INFO:l.A,S_WARNING:s.A,S_ERROR:o.A,S_FATAL:r.A},_=(0,m.cn)("yql-issue-severity");function C({severity:e}){const t=e.slice(2).toLowerCase();return(0,g.jsxs)("span",{className:_({severity:t}),children:[(0,g.jsx)(u.I,{className:_("icon"),data:S[e]}),(0,g.jsx)("span",{className:_("title"),children:t})]})}},58267:(e,t,a)=>{a.d(t,{P:()=>o,_:()=>r});var n=a(54090),l=a(6354);const s={[l.r.Dead]:n.m.Red,[l.r.Created]:n.m.Yellow,[l.r.ResolveStateStorage]:n.m.Yellow,[l.r.Candidate]:n.m.Yellow,[l.r.BlockBlobStorage]:n.m.Yellow,[l.r.WriteZeroEntry]:n.m.Yellow,[l.r.Restored]:n.m.Yellow,[l.r.Discover]:n.m.Yellow,[l.r.Lock]:n.m.Yellow,[l.r.Stopped]:n.m.Yellow,[l.r.ResolveLeader]:n.m.Yellow,[l.r.RebuildGraph]:n.m.Yellow,[l.r.Deleted]:n.m.Green,[l.r.Active]:n.m.Green},o=e=>{if(!e)return n.m.Grey;return t=e,Object.values(n.m).includes(t)?e:s[e];var t};function r(e){if(!e)return"unknown";switch(e){case l.r.Dead:return"danger";case l.r.Active:case l.r.Deleted:return"success";default:return"warning"}}},58389:(e,t,a)=>{a.d(t,{B:()=>u});var n=a(87184),l=a(77506),s=a(90053),o=a(70043),r=a(60712);const i=(0,l.cn)("ydb-page-meta"),d="\xa0\xa0\xb7\xa0\xa0";function c({items:e,loading:t}){return(0,r.jsx)("div",{className:i("info"),children:t?(0,r.jsx)(o.E,{className:i("skeleton")}):e.filter((e=>Boolean(e))).join(d)})}function u({className:e,...t}){return(0,r.jsxs)(n.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:i(null,e),children:[(0,r.jsx)(c,{...t}),(0,r.jsx)(s.E,{})]})}},70043:(e,t,a)=>{a.d(t,{E:()=>o});var n=a(89169),l=a(66781),s=a(60712);const o=({delay:e=600,className:t})=>{const[a]=(0,l.y)(e);return a?(0,s.jsx)(n.E,{className:t}):null}},74529:(e,t,a)=>{a.d(t,{A:()=>h});var n=a(59284),l=a(67884),s=a(77506),o=a(48372);const r=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),i=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),d=(0,o.g4)("ydb-shorty-string",{ru:i,en:r});var c=a(60712);const u=(0,s.cn)("kv-shorty-string");function h({value:e="",limit:t=200,strict:a=!1,displayLength:s=!0,render:o=e=>e,onToggle:r,expandLabel:i=d("default_expand_label"),collapseLabel:h=d("default_collapse_label")}){const[m,v]=n.useState(!1),p=(m?h:i)+(s&&!m?d("chars_count",{count:e.length}):""),b=e.length>t+(a?0:p.length),g=m||!b?e:e.slice(0,t-4)+"\xa0...";return(0,c.jsxs)("div",{className:u(),children:[o(g),b?(0,c.jsx)(l.N,{className:u("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),v((e=>!e)),null===r||void 0===r||r()},children:p}):null]})}},79737:(e,t,a)=>{a.d(t,{A:()=>r,X:()=>i});var n=a(5874),l=a(77506),s=a(60712);const o=(0,l.cn)("ydb-table");function r({children:e,className:t}){return(0,s.jsx)("div",{className:o("table-header-content",t),children:e})}function i({className:e,width:t,wrapperClassName:a,...l}){return(0,s.jsx)("div",{className:o(null,a),children:(0,s.jsx)(n.W,{headerCellClassName:({column:e})=>{var t;const a=null===(t=e.columnDef.meta)||void 0===t?void 0:t.align;return o("table-header-cell",{align:a})},cellClassName:e=>{var t,a;const n=null===e||void 0===e||null===(t=e.column.columnDef.meta)||void 0===t?void 0:t.align,l=null===e||void 0===e||null===(a=e.column.columnDef.meta)||void 0===a?void 0:a.verticalAlign;return o("table-cell",{align:n,"vertical-align":l})},className:o("table",{width:t},e),...l})})}},81342:(e,t,a)=>{a.r(t),a.d(t,{Tablet:()=>pe});var n=a(59284),l=a(87184),s=a(23871),o=a(44992),r=a(61750),i=a(10755),d=a(80987),c=a(370),u=a(7889),h=a(3685),m=a(44508),v=a(44294),p=a(98167),b=a(58389),g=a(92459),x=a(40174),f=a(21545),y=a(54090),w=a(77506),j=a(76086),N=a(90182),I=a(12888),T=a(76938);const S=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M4.5 1.5a3 3 0 0 0-3 3v7a3 3 0 0 0 3 3h7a3 3 0 0 0 3-3v-7a3 3 0 0 0-3-3z",clipRule:"evenodd"})),_=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",d:"M13.756 10.164c1.665-.962 1.665-3.366 0-4.328L5.251.919C3.584-.045 1.5 1.158 1.5 3.083v9.834c0 1.925 2.084 3.128 3.751 2.164z"}));var C=a(99991),A=a(22983),k=a(6354),D=a(48372);const E=JSON.parse('{"tablet.header":"Tablet","tablet.meta-database":"Database","tablet.meta-follower":"Follower","controls.kill":"Restart","controls.stop":"Stop","controls.resume":"Resume","controls.kill-not-allowed":"You don\'t have enough rights to restart tablet","controls.stop-not-allowed":"You don\'t have enough rights to stop tablet","controls.resume-not-allowed":"You don\'t have enough rights to resume tablet","dialog.kill-header":"Restart tablet","dialog.stop-header":"Stop tablet","dialog.resume-header":"Resume tablet","dialog.kill-text":"The tablet will be restarted. Do you want to proceed?","dialog.stop-text":"The tablet will be stopped. Do you want to proceed?","dialog.resume-text":"The tablet will be resumed. Do you want to proceed?","emptyState":"The tablet was not found","label_tablet-history":"Tablets","label_tablet-channels":"Storage"}'),F=(0,D.g4)("ydb-tablet-page",{en:E});function B(e){return Boolean(e&&"0"!==e)}var R=a(60712);const O=({tablet:e})=>{const{TabletId:t,HiveId:a}=e,s=(0,I.X)(),[o]=f.X.useKillTabletMutation(),[r]=f.X.useStopTabletMutation(),[i]=f.X.useResumeTabletMutation();if(!t)return null;const d=B(a),c=e.State===k.r.Stopped,u=e.State!==k.r.Stopped&&e.State!==k.r.Dead,h=e.State===k.r.Stopped||e.State===k.r.Deleted;return(0,R.jsxs)(l.s,{gap:2,wrap:"nowrap",children:[(0,R.jsxs)(A.B,{dialogHeader:F("dialog.kill-header"),dialogText:F("dialog.kill-text"),onConfirmAction:()=>o({id:t}).unwrap(),buttonDisabled:c||!s,withPopover:!0,buttonView:"normal",popoverContent:F("controls.kill-not-allowed"),popoverPlacement:"bottom",popoverDisabled:s,children:[(0,R.jsx)(C.I,{data:T.A}),F("controls.kill")]}),d&&(0,R.jsxs)(n.Fragment,{children:[(0,R.jsxs)(A.B,{dialogHeader:F("dialog.stop-header"),dialogText:F("dialog.stop-text"),onConfirmAction:()=>r({id:t,hiveId:a}).unwrap(),buttonDisabled:h||!s,withPopover:!0,buttonView:"normal",popoverContent:F("controls.stop-not-allowed"),popoverPlacement:"bottom",popoverDisabled:s,children:[(0,R.jsx)(C.I,{data:S}),F("controls.stop")]}),(0,R.jsxs)(A.B,{dialogHeader:F("dialog.resume-header"),dialogText:F("dialog.resume-text"),onConfirmAction:()=>i({id:t,hiveId:a}).unwrap(),buttonDisabled:u||!s,withPopover:!0,buttonView:"normal",popoverContent:F("controls.resume-not-allowed"),popoverPlacement:"bottom",popoverDisabled:s,children:[(0,R.jsx)(C.I,{data:_}),F("controls.resume")]})]})]})};var P=a(52905),$=a(60073),G=a(25196),H=a(27775),L=a(41826),z=a(31684),q=a(29819);const Y=JSON.parse('{"field_scheme-shard":"SchemeShard","field_follower":"Follower","field_generation":"Generation","field_hive":"HiveId","field_state":"State","field_uptime":"Uptime","field_node":"Node","field_links":"Links","field_developer-ui-app":"App","field_developer-ui-counters":"Counters","field_developer-ui-executor":"Executor DB internals","field_developer-ui-state":"State Storage","title_info":"Info","title_links":"Links"}'),M=(0,D.g4)("ydb-tablet-info",{en:Y}),K=(0,w.cn)("ydb-tablet-info"),X=({tablet:e})=>{const t=(0,I.X)(),{ChangeTime:a,Generation:n,FollowerId:s,NodeId:o,HiveId:r,State:i,TenantId:{SchemeShard:d}={},TabletId:c}=e,u=B(r),h=i===k.r.Active,m=[];u&&m.push({label:M("field_hive"),value:(0,R.jsx)(P.N_,{to:(0,g.DM)(r),className:K("link"),children:r})}),d&&m.push({label:M("field_scheme-shard"),value:(0,R.jsx)(P.N_,{to:(0,g.DM)(d),className:K("link"),children:d})}),m.push({label:M("field_state"),value:(0,R.jsx)(H.i,{state:i})}),h&&m.push({label:M("field_uptime"),value:(0,R.jsx)(L.H,{ChangeTime:a})}),m.push({label:M("field_generation"),value:n},{label:M("field_node"),value:(0,R.jsx)(P.N_,{className:K("link"),to:(0,q.vI)(String(o)),children:o})}),s&&m.push({label:M("field_follower"),value:s});return(0,R.jsxs)(l.s,{gap:10,wrap:"nowrap",children:[(0,R.jsxs)("div",{children:[(0,R.jsx)("div",{className:K("section-title"),children:M("title_info")}),(0,R.jsx)($.z_,{info:m})]}),t&&c?(0,R.jsxs)("div",{children:[(0,R.jsx)("div",{className:K("section-title"),children:M("title_links")}),(0,R.jsxs)(l.s,{direction:"column",gap:3,children:[(0,R.jsx)(G.K,{title:M("field_developer-ui-app"),url:(0,z._t)(c,"app")}),(0,R.jsx)(G.K,{title:M("field_developer-ui-counters"),url:(0,z._t)(c,"counters")}),(0,R.jsx)(G.K,{title:M("field_developer-ui-executor"),url:(0,z._t)(c,"executorInternals")}),(0,R.jsx)(G.K,{title:M("field_developer-ui-state"),url:(0,z._t)(c,void 0,"SsId")})]})]}):null]})};var Q=a(36590),J=a(79737),V=a(84476),W=a(33705),U=a(56839);const Z=JSON.parse('{"label_channel-index":"Channel","label_storage-pool":"Storage Pool Name","label_group-id":"Group ID","label_generation":"From generation","label_timestamp":"Timestamp"}'),ee=(0,D.g4)("ydb-tablet-storage-info",{en:Z}),te=(0,w.cn)("ydb-tablet-storage-info");function ae(e,t){const a=e.getValue(),n="function"===typeof t?t(a):a;return(0,R.jsx)("div",{className:te("metrics-cell"),children:n})}function ne({row:e,name:t,hasExpand:a}){const n=e.getCanExpand();return(0,R.jsxs)(l.s,{gap:1,alignItems:"flex-start",className:te("name-wrapper"),children:[n&&(0,R.jsx)(V.$,{view:"flat",size:"xs",onClick:e.getToggleExpandedHandler(),children:(0,R.jsx)(V.$.Icon,{children:(0,R.jsx)(W.I,{direction:e.getIsExpanded()?"bottom":"right",size:14})})}),(0,R.jsx)("div",{className:te("name-content",{"no-control":a&&!n}),children:t})]})}function le({data:e}){const[t,a]=n.useState({}),l=n.useMemo((()=>function(e){var t;if(!e)return[];const{BoundChannels:a,TabletStorageInfo:n={}}=e,l=null!==(t=n.Channels)&&void 0!==t?t:[],s=[];for(const r of l){var o;const e=r.Channel,t=r.History;if(!e||!t||!t.length)continue;const n=[...t];n.reverse();const[l,...i]=n,d={...l,storagePoolName:null===a||void 0===a||null===(o=a[e])||void 0===o?void 0:o.StoragePoolName,channelIndex:e,children:i};s.push(d)}return s}(e)),[e]),s=n.useMemo((()=>l.some((e=>{var t;return null===(t=e.children)||void 0===t?void 0:t.length}))),[l]),o=n.useMemo((()=>{return e=s,[{accessorKey:"channelIndex",header:()=>(0,R.jsx)(J.A,{children:ee("label_channel-index")}),size:50,cell:ae,meta:{align:"right"}},{accessorKey:"storagePoolName",header:()=>(0,R.jsx)(J.A,{children:ee("label_storage-pool")}),size:200,cell:ae},{accessorKey:"GroupID",header:()=>(0,R.jsx)(J.A,{className:e?te("with-padding"):void 0,children:ee("label_group-id")}),size:100,cell:t=>(0,R.jsx)(ne,{row:t.row,name:t.getValue(),hasExpand:e})},{accessorKey:"FromGeneration",header:()=>(0,R.jsx)(J.A,{children:ee("label_generation")}),size:100,cell:ae,meta:{align:"right"}},{accessorKey:"Timestamp",header:()=>(0,R.jsx)(J.A,{children:ee("label_timestamp")}),size:200,cell:e=>ae(e,U.Ey),meta:{align:"right"}}];var e}),[s]),r=(0,Q.K)({columns:o,data:l,getSubRows:e=>e.children,enableExpanding:!0,onExpandedChange:a,state:{expanded:t}});return(0,R.jsx)(J.X,{table:r})}var se=a(4557),oe=a(10508),re=a(82015),ie=a(17594);const de={displayIndices:!1,highlightRows:!0},ce=({history:e,database:t,tabletId:a})=>{const l=n.useMemo((()=>(({database:e,tabletId:t})=>[{name:"Generation",align:se.Ay.RIGHT,render:({row:e})=>e.generation},{name:"Change time",align:se.Ay.RIGHT,sortable:!1,render:({row:e})=>(0,R.jsx)(L.H,{ChangeTime:e.changeTime}),width:120},{name:"State",sortable:!1,render:({row:e})=>(0,R.jsx)(H.i,{state:e.state})},{name:"Tablet",sortable:!1,render:({row:a})=>{var n;const l=(0,g.DM)(t,{database:e,followerId:a.leader||null===(n=a.followerId)||void 0===n?void 0:n.toString()}),s=`${t}${a.followerId?`.${a.followerId}`:""}`;return(0,R.jsx)(re.E,{to:l,children:s})}},{name:"Node ID",align:se.Ay.RIGHT,sortable:!1,render:({row:e})=>(0,R.jsx)(re.E,{to:(0,q.vI)(e.nodeId),children:e.nodeId})},{name:"Node FQDN",sortable:!1,width:300,render:({row:e})=>e.fqdn?(0,R.jsx)(oe.c,{name:e.fqdn,showStatus:!1,hasClipboardButton:!0}):(0,R.jsx)("span",{children:"\u2014"})}])({database:t,tabletId:a})),[t,a]);return(0,R.jsx)(ie.l,{columnsWidthLSKey:"tabletTableColumnsWidth",data:e,columns:l,settings:de,initialSortOrder:{columnId:"Generation",order:se.Ay.DESCENDING}})},ue=(0,w.cn)("ydb-tablet-page"),he={history:"history",channels:"channels"},me=[{id:he.history,get title(){return F("label_tablet-history")}},{id:he.channels,get title(){return F("label_tablet-channels")},isAdvanced:!0}],ve=c.z.nativeEnum(he).catch(he.history);function pe(){var e;const t=(0,N.YQ)(),{id:a}=(0,i.g)(),[{database:s,clusterName:c,followerId:u}]=(0,d.useQueryParams)(g.qc),[h]=(0,N.Nt)(),{currentData:v,isFetching:y,error:w}=f.X.useGetTabletQuery({id:a,database:null!==s&&void 0!==s?s:void 0,followerId:null!==u&&void 0!==u?u:void 0},{pollingInterval:h}),I=y&&void 0===v,{data:T={},history:S=[]}=v||{},{currentData:_}=f.X.useGetTabletDescribeQuery(T.TenantId?{tenantId:T.TenantId}:o.hT),C=null!==(e=_||s)&&void 0!==e?e:void 0,A=T.Type;n.useEffect((()=>{t((0,x.g)("tablet",{tenantName:null!==s&&void 0!==s?s:void 0,tabletId:a,tabletType:A}))}),[t,s,a,A]);const{Leader:k,Type:D}=T,E=[];return C&&E.push(`${F("tablet.meta-database")}: ${C}`),D&&E.push(D),!1===k&&E.push(F("tablet.meta-follower").toUpperCase()),(0,R.jsxs)(l.s,{gap:5,direction:"column",className:ue(),children:[(0,R.jsx)(r.mg,{children:(0,R.jsx)("title",{children:`${a} \u2014 ${F("tablet.header")} \u2014 ${C||c||j.QM}`})}),(0,R.jsx)(b.B,{items:E}),(0,R.jsxs)(p.r,{loading:I,size:"l",children:[w?(0,R.jsx)(m.o,{error:w}):null,v?(0,R.jsx)(be,{id:a,tablet:T,history:S,database:C}):null]})]})}function be({id:e,tablet:t,history:a,database:n}){const s=!Object.keys(t).length,{Overall:o,HiveId:r,FollowerId:i}=t,d=`${e}${i?`.${i}`:""}`;return(0,R.jsxs)(u.q,{title:F("emptyState"),className:ue("placeholder"),isEmpty:s,children:[(0,R.jsxs)(l.s,{gap:5,direction:"column",children:[(0,R.jsx)(h.$,{entityName:F("tablet.header"),status:null!==o&&void 0!==o?o:y.m.Grey,id:d}),(0,R.jsx)(O,{tablet:t}),(0,R.jsx)(X,{tablet:t})]}),(0,R.jsx)(ge,{id:e,hiveId:r,history:a,database:n})]})}function ge({id:e,hiveId:t,history:a,database:o}){var r;const[{activeTab:i,...c},u]=(0,d.useQueryParams)(g.qc),h=!(0,I.X)()||!B(t);let m=ve.parse(i);return h&&null!==(r=me.find((e=>e.id===m)))&&void 0!==r&&r.isAdvanced&&(m=he.history),n.useEffect((()=>{i!==m&&u({activeTab:m},"replaceIn")}),[i,m,u]),(0,R.jsxs)(l.s,{gap:5,direction:"column",children:[(0,R.jsx)("div",{children:(0,R.jsx)(s.t,{size:"l",items:me.filter((({isAdvanced:e})=>!e||!h)),activeTab:m,wrapTo:(t,a)=>{const n=(0,g.DM)(e,{...c,activeTab:t.id});return(0,R.jsx)(v.E,{to:n,children:a},t.id)}})}),"history"===m?(0,R.jsx)(ce,{history:a,tabletId:e,database:o}):null,"channels"!==m||h?null:(0,R.jsx)(xe,{id:e,hiveId:t})]})}function xe({id:e,hiveId:t}){const[a]=(0,N.Nt)(),{currentData:n,error:l,isFetching:s}=f.X.useGetAdvancedTableInfoQuery({id:e,hiveId:t},{pollingInterval:a}),o=s&&void 0===n;return(0,R.jsxs)(p.r,{loading:o,size:"l",children:[l?(0,R.jsx)(m.o,{error:l}):null,n?(0,R.jsx)(le,{data:n}):null]})}},90053:(e,t,a)=>{a.d(t,{E:()=>v});var n=a(8873),l=a(84476),s=a(24555),o=a(21334),r=a(77506),i=a(90182),d=a(48372);const c=JSON.parse('{"None":"None","15 sec":"15 sec","1 min":"1 min","2 min":"2 min","5 min":"5 min","Refresh":"Refresh"}'),u=(0,d.g4)("ydb-diagnostics-autorefresh-control",{en:c});var h=a(60712);const m=(0,r.cn)("auto-refresh-control");function v({className:e,onManualRefresh:t}){const a=(0,i.YQ)(),[r,d]=(0,i.Nt)();return(0,h.jsxs)("div",{className:m(null,e),children:[(0,h.jsx)(l.$,{view:"flat-secondary",onClick:()=>{a(o.F.util.invalidateTags(["All"])),null===t||void 0===t||t()},extraProps:{"aria-label":u("Refresh")},children:(0,h.jsx)(l.$.Icon,{children:(0,h.jsx)(n.A,{})})}),(0,h.jsxs)(s.l,{value:[String(r)],onUpdate:e=>{d(Number(e))},width:85,qa:"ydb-autorefresh-select",children:[(0,h.jsx)(s.l.Option,{value:"0",children:u("None")}),(0,h.jsx)(s.l.Option,{value:"15000",children:u("15 sec")}),(0,h.jsx)(s.l.Option,{value:"60000",children:u("1 min")}),(0,h.jsx)(s.l.Option,{value:"120000",children:u("2 min")}),(0,h.jsx)(s.l.Option,{value:"300000",children:u("5 min")})]})]})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/49523.654b328e.chunk.js b/ydb/core/viewer/monitoring/static/js/49523.654b328e.chunk.js new file mode 100644 index 000000000000..3bfe23a3b54a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49523.654b328e.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49523],{49523:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"dv",weekdays:"\u0787\u07a7\u078b\u07a8\u0787\u07b0\u078c\u07a6_\u0780\u07af\u0789\u07a6_\u0787\u07a6\u0782\u07b0\u078e\u07a7\u0783\u07a6_\u0784\u07aa\u078b\u07a6_\u0784\u07aa\u0783\u07a7\u0790\u07b0\u078a\u07a6\u078c\u07a8_\u0780\u07aa\u0786\u07aa\u0783\u07aa_\u0780\u07ae\u0782\u07a8\u0780\u07a8\u0783\u07aa".split("_"),months:"\u0796\u07ac\u0782\u07aa\u0787\u07a6\u0783\u07a9_\u078a\u07ac\u0784\u07b0\u0783\u07aa\u0787\u07a6\u0783\u07a9_\u0789\u07a7\u0783\u07a8\u0797\u07aa_\u0787\u07ad\u0795\u07b0\u0783\u07a9\u078d\u07aa_\u0789\u07ad_\u0796\u07ab\u0782\u07b0_\u0796\u07aa\u078d\u07a6\u0787\u07a8_\u0787\u07af\u078e\u07a6\u0790\u07b0\u0793\u07aa_\u0790\u07ac\u0795\u07b0\u0793\u07ac\u0789\u07b0\u0784\u07a6\u0783\u07aa_\u0787\u07ae\u0786\u07b0\u0793\u07af\u0784\u07a6\u0783\u07aa_\u0782\u07ae\u0788\u07ac\u0789\u07b0\u0784\u07a6\u0783\u07aa_\u0791\u07a8\u0790\u07ac\u0789\u07b0\u0784\u07a6\u0783\u07aa".split("_"),weekStart:7,weekdaysShort:"\u0787\u07a7\u078b\u07a8\u0787\u07b0\u078c\u07a6_\u0780\u07af\u0789\u07a6_\u0787\u07a6\u0782\u07b0\u078e\u07a7\u0783\u07a6_\u0784\u07aa\u078b\u07a6_\u0784\u07aa\u0783\u07a7\u0790\u07b0\u078a\u07a6\u078c\u07a8_\u0780\u07aa\u0786\u07aa\u0783\u07aa_\u0780\u07ae\u0782\u07a8\u0780\u07a8\u0783\u07aa".split("_"),monthsShort:"\u0796\u07ac\u0782\u07aa\u0787\u07a6\u0783\u07a9_\u078a\u07ac\u0784\u07b0\u0783\u07aa\u0787\u07a6\u0783\u07a9_\u0789\u07a7\u0783\u07a8\u0797\u07aa_\u0787\u07ad\u0795\u07b0\u0783\u07a9\u078d\u07aa_\u0789\u07ad_\u0796\u07ab\u0782\u07b0_\u0796\u07aa\u078d\u07a6\u0787\u07a8_\u0787\u07af\u078e\u07a6\u0790\u07b0\u0793\u07aa_\u0790\u07ac\u0795\u07b0\u0793\u07ac\u0789\u07b0\u0784\u07a6\u0783\u07aa_\u0787\u07ae\u0786\u07b0\u0793\u07af\u0784\u07a6\u0783\u07aa_\u0782\u07ae\u0788\u07ac\u0789\u07b0\u0784\u07a6\u0783\u07aa_\u0791\u07a8\u0790\u07ac\u0789\u07b0\u0784\u07a6\u0783\u07aa".split("_"),weekdaysMin:"\u0787\u07a7\u078b\u07a8_\u0780\u07af\u0789\u07a6_\u0787\u07a6\u0782\u07b0_\u0784\u07aa\u078b\u07a6_\u0784\u07aa\u0783\u07a7_\u0780\u07aa\u0786\u07aa_\u0780\u07ae\u0782\u07a8".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"D/M/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"\u078c\u07ac\u0783\u07ad\u078e\u07a6\u0787\u07a8 %s",past:"\u0786\u07aa\u0783\u07a8\u0782\u07b0 %s",s:"\u0790\u07a8\u0786\u07aa\u0782\u07b0\u078c\u07aa\u0786\u07ae\u0785\u07ac\u0787\u07b0",m:"\u0789\u07a8\u0782\u07a8\u0793\u07ac\u0787\u07b0",mm:"\u0789\u07a8\u0782\u07a8\u0793\u07aa %d",h:"\u078e\u07a6\u0791\u07a8\u0787\u07a8\u0783\u07ac\u0787\u07b0",hh:"\u078e\u07a6\u0791\u07a8\u0787\u07a8\u0783\u07aa %d",d:"\u078b\u07aa\u0788\u07a6\u0780\u07ac\u0787\u07b0",dd:"\u078b\u07aa\u0788\u07a6\u0790\u07b0 %d",M:"\u0789\u07a6\u0780\u07ac\u0787\u07b0",MM:"\u0789\u07a6\u0790\u07b0 %d",y:"\u0787\u07a6\u0780\u07a6\u0783\u07ac\u0787\u07b0",yy:"\u0787\u07a6\u0780\u07a6\u0783\u07aa %d"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/49582.c5a749cc.chunk.js b/ydb/core/viewer/monitoring/static/js/49582.c5a749cc.chunk.js new file mode 100644 index 000000000000..620a645545be --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49582.c5a749cc.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 49582.c5a749cc.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49582],{49582:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>o});var i={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]}]},o={tokenPostfix:".pats",defaultToken:"invalid",keywords:["abstype","abst0ype","absprop","absview","absvtype","absviewtype","absvt0ype","absviewt0ype","as","and","assume","begin","classdec","datasort","datatype","dataprop","dataview","datavtype","dataviewtype","do","end","extern","extype","extvar","exception","fn","fnx","fun","prfn","prfun","praxi","castfn","if","then","else","ifcase","in","infix","infixl","infixr","prefix","postfix","implmnt","implement","primplmnt","primplement","import","let","local","macdef","macrodef","nonfix","symelim","symintr","overload","of","op","rec","sif","scase","sortdef","sta","stacst","stadef","static","staload","dynload","try","tkindef","typedef","propdef","viewdef","vtypedef","viewtypedef","prval","var","prvar","when","where","with","withtype","withprop","withview","withvtype","withviewtype"],keywords_dlr:["$delay","$ldelay","$arrpsz","$arrptrsize","$d2ctype","$effmask","$effmask_ntm","$effmask_exn","$effmask_ref","$effmask_wrt","$effmask_all","$extern","$extkind","$extype","$extype_struct","$extval","$extfcall","$extmcall","$literal","$myfilename","$mylocation","$myfunction","$lst","$lst_t","$lst_vt","$list","$list_t","$list_vt","$rec","$rec_t","$rec_vt","$record","$record_t","$record_vt","$tup","$tup_t","$tup_vt","$tuple","$tuple_t","$tuple_vt","$break","$continue","$raise","$showtype","$vcopyenv_v","$vcopyenv_vt","$tempenver","$solver_assert","$solver_verify"],keywords_srp:["#if","#ifdef","#ifndef","#then","#elif","#elifdef","#elifndef","#else","#endif","#error","#prerr","#print","#assert","#undef","#define","#include","#require","#pragma","#codegen2","#codegen3"],irregular_keyword_list:["val+","val-","val","case+","case-","case","addr@","addr","fold@","free@","fix@","fix","lam@","lam","llam@","llam","viewt@ype+","viewt@ype-","viewt@ype","viewtype+","viewtype-","viewtype","view+","view-","view@","view","type+","type-","type","vtype+","vtype-","vtype","vt@ype+","vt@ype-","vt@ype","viewt@ype+","viewt@ype-","viewt@ype","viewtype+","viewtype-","viewtype","prop+","prop-","prop","type+","type-","type","t@ype","t@ype+","t@ype-","abst@ype","abstype","absviewt@ype","absvt@ype","for*","for","while*","while"],keywords_types:["bool","double","byte","int","short","char","void","unit","long","float","string","strptr"],keywords_effects:["0","fun","clo","prf","funclo","cloptr","cloref","ref","ntm","1"],operators:["@","!","|","`",":","$",".","=","#","~","..","...","=>","=<>","=/=>","=>>","=/=>>","<",">","><",".<",">.",".<>.","->","-<>"],brackets:[{open:",(",close:")",token:"delimiter.parenthesis"},{open:"`(",close:")",token:"delimiter.parenthesis"},{open:"%(",close:")",token:"delimiter.parenthesis"},{open:"'(",close:")",token:"delimiter.parenthesis"},{open:"'{",close:"}",token:"delimiter.parenthesis"},{open:"@(",close:")",token:"delimiter.parenthesis"},{open:"@{",close:"}",token:"delimiter.brace"},{open:"@[",close:"]",token:"delimiter.square"},{open:"#[",close:"]",token:"delimiter.square"},{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],symbols:/[=>]/,digit:/[0-9]/,digitseq0:/@digit*/,xdigit:/[0-9A-Za-z]/,xdigitseq0:/@xdigit*/,INTSP:/[lLuU]/,FLOATSP:/[fFlL]/,fexponent:/[eE][+-]?[0-9]+/,fexponent_bin:/[pP][+-]?[0-9]+/,deciexp:/\.[0-9]*@fexponent?/,hexiexp:/\.[0-9a-zA-Z]*@fexponent_bin?/,irregular_keywords:/val[+-]?|case[+-]?|addr\@?|fold\@|free\@|fix\@?|lam\@?|llam\@?|prop[+-]?|type[+-]?|view[+-@]?|viewt@?ype[+-]?|t@?ype[+-]?|v(iew)?t@?ype[+-]?|abst@?ype|absv(iew)?t@?ype|for\*?|while\*?/,ESCHAR:/[ntvbrfa\\\?'"\(\[\{]/,start:"root",tokenizer:{root:[{regex:/[ \t\r\n]+/,action:{token:""}},{regex:/\(\*\)/,action:{token:"invalid"}},{regex:/\(\*/,action:{token:"comment",next:"lexing_COMMENT_block_ml"}},{regex:/\(/,action:"@brackets"},{regex:/\)/,action:"@brackets"},{regex:/\[/,action:"@brackets"},{regex:/\]/,action:"@brackets"},{regex:/\{/,action:"@brackets"},{regex:/\}/,action:"@brackets"},{regex:/,\(/,action:"@brackets"},{regex:/,/,action:{token:"delimiter.comma"}},{regex:/;/,action:{token:"delimiter.semicolon"}},{regex:/@\(/,action:"@brackets"},{regex:/@\[/,action:"@brackets"},{regex:/@\{/,action:"@brackets"},{regex:/:/,action:{token:"@rematch",next:"@pop"}}],lexing_EXTCODE:[{regex:/^%}/,action:{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}},{regex:/[^%]+/,action:""}],lexing_DQUOTE:[{regex:/"/,action:{token:"string.quote",next:"@pop"}},{regex:/(\{\$)(@IDENTFST@IDENTRST*)(\})/,action:[{token:"string.escape"},{token:"identifier"},{token:"string.escape"}]},{regex:/\\$/,action:{token:"string.escape"}},{regex:/\\(@ESCHAR|[xX]@xdigit+|@digit+)/,action:{token:"string.escape"}},{regex:/[^\\"]+/,action:{token:"string"}}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4678.4e2f4af4.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/49582.c5a749cc.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/4678.4e2f4af4.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/49582.c5a749cc.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/49725.3529a00c.chunk.js b/ydb/core/viewer/monitoring/static/js/49725.3529a00c.chunk.js new file mode 100644 index 000000000000..5b8155c05832 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49725.3529a00c.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49725],{49725:function(e,_,s){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var s=_(e),o={name:"es",monthsShort:"ene_feb_mar_abr_may_jun_jul_ago_sep_oct_nov_dic".split("_"),weekdays:"domingo_lunes_martes_mi\xe9rcoles_jueves_viernes_s\xe1bado".split("_"),weekdaysShort:"dom._lun._mar._mi\xe9._jue._vie._s\xe1b.".split("_"),weekdaysMin:"do_lu_ma_mi_ju_vi_s\xe1".split("_"),months:"enero_febrero_marzo_abril_mayo_junio_julio_agosto_septiembre_octubre_noviembre_diciembre".split("_"),weekStart:1,formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY H:mm",LLLL:"dddd, D [de] MMMM [de] YYYY H:mm"},relativeTime:{future:"en %s",past:"hace %s",s:"unos segundos",m:"un minuto",mm:"%d minutos",h:"una hora",hh:"%d horas",d:"un d\xeda",dd:"%d d\xedas",M:"un mes",MM:"%d meses",y:"un a\xf1o",yy:"%d a\xf1os"},ordinal:function(e){return e+"\xba"}};return s.default.locale(o,null,!0),o}(s(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/49778.b9d397f4.chunk.js b/ydb/core/viewer/monitoring/static/js/49778.b9d397f4.chunk.js new file mode 100644 index 000000000000..686043b4d57c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49778.b9d397f4.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 49778.b9d397f4.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49778],{49778:(E,T,R)=>{R.r(T),R.d(T,{conf:()=>A,language:()=>I});var A={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},I={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ABORT","ABSOLUTE","ACTION","ADA","ADD","AFTER","ALL","ALLOCATE","ALTER","ALWAYS","ANALYZE","AND","ANY","ARE","AS","ASC","ASSERTION","AT","ATTACH","AUTHORIZATION","AUTOINCREMENT","AVG","BACKUP","BEFORE","BEGIN","BETWEEN","BIT","BIT_LENGTH","BOTH","BREAK","BROWSE","BULK","BY","CASCADE","CASCADED","CASE","CAST","CATALOG","CHAR","CHARACTER","CHARACTER_LENGTH","CHAR_LENGTH","CHECK","CHECKPOINT","CLOSE","CLUSTERED","COALESCE","COLLATE","COLLATION","COLUMN","COMMIT","COMPUTE","CONFLICT","CONNECT","CONNECTION","CONSTRAINT","CONSTRAINTS","CONTAINS","CONTAINSTABLE","CONTINUE","CONVERT","CORRESPONDING","COUNT","CREATE","CROSS","CURRENT","CURRENT_DATE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURSOR","DATABASE","DATE","DAY","DBCC","DEALLOCATE","DEC","DECIMAL","DECLARE","DEFAULT","DEFERRABLE","DEFERRED","DELETE","DENY","DESC","DESCRIBE","DESCRIPTOR","DETACH","DIAGNOSTICS","DISCONNECT","DISK","DISTINCT","DISTRIBUTED","DO","DOMAIN","DOUBLE","DROP","DUMP","EACH","ELSE","END","END-EXEC","ERRLVL","ESCAPE","EXCEPT","EXCEPTION","EXCLUDE","EXCLUSIVE","EXEC","EXECUTE","EXISTS","EXIT","EXPLAIN","EXTERNAL","EXTRACT","FAIL","FALSE","FETCH","FILE","FILLFACTOR","FILTER","FIRST","FLOAT","FOLLOWING","FOR","FOREIGN","FORTRAN","FOUND","FREETEXT","FREETEXTTABLE","FROM","FULL","FUNCTION","GENERATED","GET","GLOB","GLOBAL","GO","GOTO","GRANT","GROUP","GROUPS","HAVING","HOLDLOCK","HOUR","IDENTITY","IDENTITYCOL","IDENTITY_INSERT","IF","IGNORE","IMMEDIATE","IN","INCLUDE","INDEX","INDEXED","INDICATOR","INITIALLY","INNER","INPUT","INSENSITIVE","INSERT","INSTEAD","INT","INTEGER","INTERSECT","INTERVAL","INTO","IS","ISNULL","ISOLATION","JOIN","KEY","KILL","LANGUAGE","LAST","LEADING","LEFT","LEVEL","LIKE","LIMIT","LINENO","LOAD","LOCAL","LOWER","MATCH","MATERIALIZED","MAX","MERGE","MIN","MINUTE","MODULE","MONTH","NAMES","NATIONAL","NATURAL","NCHAR","NEXT","NO","NOCHECK","NONCLUSTERED","NONE","NOT","NOTHING","NOTNULL","NULL","NULLIF","NULLS","NUMERIC","OCTET_LENGTH","OF","OFF","OFFSET","OFFSETS","ON","ONLY","OPEN","OPENDATASOURCE","OPENQUERY","OPENROWSET","OPENXML","OPTION","OR","ORDER","OTHERS","OUTER","OUTPUT","OVER","OVERLAPS","PAD","PARTIAL","PARTITION","PASCAL","PERCENT","PIVOT","PLAN","POSITION","PRAGMA","PRECEDING","PRECISION","PREPARE","PRESERVE","PRIMARY","PRINT","PRIOR","PRIVILEGES","PROC","PROCEDURE","PUBLIC","QUERY","RAISE","RAISERROR","RANGE","READ","READTEXT","REAL","RECONFIGURE","RECURSIVE","REFERENCES","REGEXP","REINDEX","RELATIVE","RELEASE","RENAME","REPLACE","REPLICATION","RESTORE","RESTRICT","RETURN","RETURNING","REVERT","REVOKE","RIGHT","ROLLBACK","ROW","ROWCOUNT","ROWGUIDCOL","ROWS","RULE","SAVE","SAVEPOINT","SCHEMA","SCROLL","SECOND","SECTION","SECURITYAUDIT","SELECT","SEMANTICKEYPHRASETABLE","SEMANTICSIMILARITYDETAILSTABLE","SEMANTICSIMILARITYTABLE","SESSION","SESSION_USER","SET","SETUSER","SHUTDOWN","SIZE","SMALLINT","SOME","SPACE","SQL","SQLCA","SQLCODE","SQLERROR","SQLSTATE","SQLWARNING","STATISTICS","SUBSTRING","SUM","SYSTEM_USER","TABLE","TABLESAMPLE","TEMP","TEMPORARY","TEXTSIZE","THEN","TIES","TIME","TIMESTAMP","TIMEZONE_HOUR","TIMEZONE_MINUTE","TO","TOP","TRAILING","TRAN","TRANSACTION","TRANSLATE","TRANSLATION","TRIGGER","TRIM","TRUE","TRUNCATE","TRY_CONVERT","TSEQUAL","UNBOUNDED","UNION","UNIQUE","UNKNOWN","UNPIVOT","UPDATE","UPDATETEXT","UPPER","USAGE","USE","USER","USING","VACUUM","VALUE","VALUES","VARCHAR","VARYING","VIEW","VIRTUAL","WAITFOR","WHEN","WHENEVER","WHERE","WHILE","WINDOW","WITH","WITHIN GROUP","WITHOUT","WORK","WRITE","WRITETEXT","YEAR","ZONE"],operators:["ALL","AND","ANY","BETWEEN","EXISTS","IN","LIKE","NOT","OR","SOME","EXCEPT","INTERSECT","UNION","APPLY","CROSS","FULL","INNER","JOIN","LEFT","OUTER","RIGHT","CONTAINS","FREETEXT","IS","NULL","PIVOT","UNPIVOT","MATCHED"],builtinFunctions:["AVG","CHECKSUM_AGG","COUNT","COUNT_BIG","GROUPING","GROUPING_ID","MAX","MIN","SUM","STDEV","STDEVP","VAR","VARP","CUME_DIST","FIRST_VALUE","LAG","LAST_VALUE","LEAD","PERCENTILE_CONT","PERCENTILE_DISC","PERCENT_RANK","COLLATE","COLLATIONPROPERTY","TERTIARY_WEIGHTS","FEDERATION_FILTERING_VALUE","CAST","CONVERT","PARSE","TRY_CAST","TRY_CONVERT","TRY_PARSE","ASYMKEY_ID","ASYMKEYPROPERTY","CERTPROPERTY","CERT_ID","CRYPT_GEN_RANDOM","DECRYPTBYASYMKEY","DECRYPTBYCERT","DECRYPTBYKEY","DECRYPTBYKEYAUTOASYMKEY","DECRYPTBYKEYAUTOCERT","DECRYPTBYPASSPHRASE","ENCRYPTBYASYMKEY","ENCRYPTBYCERT","ENCRYPTBYKEY","ENCRYPTBYPASSPHRASE","HASHBYTES","IS_OBJECTSIGNED","KEY_GUID","KEY_ID","KEY_NAME","SIGNBYASYMKEY","SIGNBYCERT","SYMKEYPROPERTY","VERIFYSIGNEDBYCERT","VERIFYSIGNEDBYASYMKEY","CURSOR_STATUS","DATALENGTH","IDENT_CURRENT","IDENT_INCR","IDENT_SEED","IDENTITY","SQL_VARIANT_PROPERTY","CURRENT_TIMESTAMP","DATEADD","DATEDIFF","DATEFROMPARTS","DATENAME","DATEPART","DATETIME2FROMPARTS","DATETIMEFROMPARTS","DATETIMEOFFSETFROMPARTS","DAY","EOMONTH","GETDATE","GETUTCDATE","ISDATE","MONTH","SMALLDATETIMEFROMPARTS","SWITCHOFFSET","SYSDATETIME","SYSDATETIMEOFFSET","SYSUTCDATETIME","TIMEFROMPARTS","TODATETIMEOFFSET","YEAR","CHOOSE","COALESCE","IIF","NULLIF","ABS","ACOS","ASIN","ATAN","ATN2","CEILING","COS","COT","DEGREES","EXP","FLOOR","LOG","LOG10","PI","POWER","RADIANS","RAND","ROUND","SIGN","SIN","SQRT","SQUARE","TAN","APP_NAME","APPLOCK_MODE","APPLOCK_TEST","ASSEMBLYPROPERTY","COL_LENGTH","COL_NAME","COLUMNPROPERTY","DATABASE_PRINCIPAL_ID","DATABASEPROPERTYEX","DB_ID","DB_NAME","FILE_ID","FILE_IDEX","FILE_NAME","FILEGROUP_ID","FILEGROUP_NAME","FILEGROUPPROPERTY","FILEPROPERTY","FULLTEXTCATALOGPROPERTY","FULLTEXTSERVICEPROPERTY","INDEX_COL","INDEXKEY_PROPERTY","INDEXPROPERTY","OBJECT_DEFINITION","OBJECT_ID","OBJECT_NAME","OBJECT_SCHEMA_NAME","OBJECTPROPERTY","OBJECTPROPERTYEX","ORIGINAL_DB_NAME","PARSENAME","SCHEMA_ID","SCHEMA_NAME","SCOPE_IDENTITY","SERVERPROPERTY","STATS_DATE","TYPE_ID","TYPE_NAME","TYPEPROPERTY","DENSE_RANK","NTILE","RANK","ROW_NUMBER","PUBLISHINGSERVERNAME","OPENDATASOURCE","OPENQUERY","OPENROWSET","OPENXML","CERTENCODED","CERTPRIVATEKEY","CURRENT_USER","HAS_DBACCESS","HAS_PERMS_BY_NAME","IS_MEMBER","IS_ROLEMEMBER","IS_SRVROLEMEMBER","LOGINPROPERTY","ORIGINAL_LOGIN","PERMISSIONS","PWDENCRYPT","PWDCOMPARE","SESSION_USER","SESSIONPROPERTY","SUSER_ID","SUSER_NAME","SUSER_SID","SUSER_SNAME","SYSTEM_USER","USER","USER_ID","USER_NAME","ASCII","CHAR","CHARINDEX","CONCAT","DIFFERENCE","FORMAT","LEFT","LEN","LOWER","LTRIM","NCHAR","PATINDEX","QUOTENAME","REPLACE","REPLICATE","REVERSE","RIGHT","RTRIM","SOUNDEX","SPACE","STR","STUFF","SUBSTRING","UNICODE","UPPER","BINARY_CHECKSUM","CHECKSUM","CONNECTIONPROPERTY","CONTEXT_INFO","CURRENT_REQUEST_ID","ERROR_LINE","ERROR_NUMBER","ERROR_MESSAGE","ERROR_PROCEDURE","ERROR_SEVERITY","ERROR_STATE","FORMATMESSAGE","GETANSINULL","GET_FILESTREAM_TRANSACTION_CONTEXT","HOST_ID","HOST_NAME","ISNULL","ISNUMERIC","MIN_ACTIVE_ROWVERSION","NEWID","NEWSEQUENTIALID","ROWCOUNT_BIG","XACT_STATE","TEXTPTR","TEXTVALID","COLUMNS_UPDATED","EVENTDATA","TRIGGER_NESTLEVEL","UPDATE","CHANGETABLE","CHANGE_TRACKING_CONTEXT","CHANGE_TRACKING_CURRENT_VERSION","CHANGE_TRACKING_IS_COLUMN_IN_MASK","CHANGE_TRACKING_MIN_VALID_VERSION","CONTAINSTABLE","FREETEXTTABLE","SEMANTICKEYPHRASETABLE","SEMANTICSIMILARITYDETAILSTABLE","SEMANTICSIMILARITYTABLE","FILETABLEROOTPATH","GETFILENAMESPACEPATH","GETPATHLOCATOR","PATHNAME","GET_TRANSMISSION_STATUS"],builtinVariables:["@@DATEFIRST","@@DBTS","@@LANGID","@@LANGUAGE","@@LOCK_TIMEOUT","@@MAX_CONNECTIONS","@@MAX_PRECISION","@@NESTLEVEL","@@OPTIONS","@@REMSERVER","@@SERVERNAME","@@SERVICENAME","@@SPID","@@TEXTSIZE","@@VERSION","@@CURSOR_ROWS","@@FETCH_STATUS","@@DATEFIRST","@@PROCID","@@ERROR","@@IDENTITY","@@ROWCOUNT","@@TRANCOUNT","@@CONNECTIONS","@@CPU_BUSY","@@IDLE","@@IO_BUSY","@@PACKET_ERRORS","@@PACK_RECEIVED","@@PACK_SENT","@@TIMETICKS","@@TOTAL_ERRORS","@@TOTAL_READ","@@TOTAL_WRITE"],pseudoColumns:["$ACTION","$IDENTITY","$ROWGUID","$PARTITION"],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@keywords":"keyword","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/N'/,{token:"string",next:"@string"}],[/'/,{token:"string",next:"@string"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],complexIdentifiers:[[/\[/,{token:"identifier.quote",next:"@bracketedIdentifier"}],[/"/,{token:"identifier.quote",next:"@quotedIdentifier"}]],bracketedIdentifier:[[/[^\]]+/,"identifier"],[/]]/,"identifier"],[/]/,{token:"identifier.quote",next:"@pop"}]],quotedIdentifier:[[/[^"]+/,"identifier"],[/""/,"identifier"],[/"/,{token:"identifier.quote",next:"@pop"}]],scopes:[[/BEGIN\s+(DISTRIBUTED\s+)?TRAN(SACTION)?\b/i,"keyword"],[/BEGIN\s+TRY\b/i,{token:"keyword.try"}],[/END\s+TRY\b/i,{token:"keyword.try"}],[/BEGIN\s+CATCH\b/i,{token:"keyword.catch"}],[/END\s+CATCH\b/i,{token:"keyword.catch"}],[/(BEGIN|CASE)\b/i,{token:"keyword.block"}],[/END\b/i,{token:"keyword.block"}],[/WHEN\b/i,{token:"keyword.choice"}],[/THEN\b/i,{token:"keyword.choice"}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/4870.1916a88d.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/49778.b9d397f4.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/4870.1916a88d.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/49778.b9d397f4.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/49788.12d03dd2.chunk.js b/ydb/core/viewer/monitoring/static/js/49788.12d03dd2.chunk.js new file mode 100644 index 000000000000..58133c155d67 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/49788.12d03dd2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[49788],{32933:e=>{function t(e){e.languages.monkey={comment:{pattern:/^#Rem\s[\s\S]*?^#End|'.+/im,greedy:!0},string:{pattern:/"[^"\r\n]*"/,greedy:!0},preprocessor:{pattern:/(^[ \t]*)#.+/m,lookbehind:!0,greedy:!0,alias:"property"},function:/\b\w+(?=\()/,"type-char":{pattern:/\b[?%#$]/,alias:"class-name"},number:{pattern:/((?:\.\.)?)(?:(?:\b|\B-\.?|\B\.)\d+(?:(?!\.\.)\.\d*)?|\$[\da-f]+)/i,lookbehind:!0},keyword:/\b(?:Abstract|Array|Bool|Case|Catch|Class|Const|Continue|Default|Eachin|Else|ElseIf|End|EndIf|Exit|Extends|Extern|False|Field|Final|Float|For|Forever|Function|Global|If|Implements|Import|Inline|Int|Interface|Local|Method|Module|New|Next|Null|Object|Private|Property|Public|Repeat|Return|Select|Self|Step|Strict|String|Super|Then|Throw|To|True|Try|Until|Void|Wend|While)\b/i,operator:/\.\.|<[=>]?|>=?|:?=|(?:[+\-*\/&~|]|\b(?:Mod|Shl|Shr)\b)=?|\b(?:And|Not|Or)\b/i,punctuation:/[.,:;()\[\]]/}}e.exports=t,t.displayName="monkey",t.aliases=[]},49788:(e,t,n)=>{n.d(t,{default:()=>a});var r=n(32933);const a=n.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/50045.c8e44e5c.chunk.js b/ydb/core/viewer/monitoring/static/js/50045.c8e44e5c.chunk.js new file mode 100644 index 000000000000..f959484d57b5 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/50045.c8e44e5c.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[50045],{25712:(e,t,n)=>{var a=n(51572);function o(e){e.register(a),e.languages.liquid={comment:{pattern:/(^\{%\s*comment\s*%\})[\s\S]+(?=\{%\s*endcomment\s*%\}$)/,lookbehind:!0},delimiter:{pattern:/^\{(?:\{\{|[%\{])-?|-?(?:\}\}|[%\}])\}$/,alias:"punctuation"},string:{pattern:/"[^"]*"|'[^']*'/,greedy:!0},keyword:/\b(?:as|assign|break|(?:end)?(?:capture|case|comment|for|form|if|paginate|raw|style|tablerow|unless)|continue|cycle|decrement|echo|else|elsif|in|include|increment|limit|liquid|offset|range|render|reversed|section|when|with)\b/,object:/\b(?:address|all_country_option_tags|article|block|blog|cart|checkout|collection|color|country|country_option_tags|currency|current_page|current_tags|customer|customer_address|date|discount_allocation|discount_application|external_video|filter|filter_value|font|forloop|fulfillment|generic_file|gift_card|group|handle|image|line_item|link|linklist|localization|location|measurement|media|metafield|model|model_source|order|page|page_description|page_image|page_title|part|policy|product|product_option|recommendations|request|robots|routes|rule|script|search|selling_plan|selling_plan_allocation|selling_plan_group|shipping_method|shop|shop_locale|sitemap|store_availability|tax_line|template|theme|transaction|unit_price_measurement|user_agent|variant|video|video_source)\b/,function:[{pattern:/(\|\s*)\w+/,lookbehind:!0,alias:"filter"},{pattern:/(\.\s*)(?:first|last|size)/,lookbehind:!0}],boolean:/\b(?:false|nil|true)\b/,range:{pattern:/\.\./,alias:"operator"},number:/\b\d+(?:\.\d+)?\b/,operator:/[!=]=|<>|[<>]=?|[|?:=-]|\b(?:and|contains(?=\s)|or)\b/,punctuation:/[.,\[\]()]/,empty:{pattern:/\bempty\b/,alias:"keyword"}},e.hooks.add("before-tokenize",(function(t){var n=!1;e.languages["markup-templating"].buildPlaceholders(t,"liquid",/\{%\s*comment\s*%\}[\s\S]*?\{%\s*endcomment\s*%\}|\{(?:%[\s\S]*?%|\{\{[\s\S]*?\}\}|\{[\s\S]*?\})\}/g,(function(e){var t=/^\{%-?\s*(\w+)/.exec(e);if(t){var a=t[1];if("raw"===a&&!n)return n=!0,!0;if("endraw"===a)return n=!1,!0}return!n}))})),e.hooks.add("after-tokenize",(function(t){e.languages["markup-templating"].tokenizePlaceholders(t,"liquid")}))}e.exports=o,o.displayName="liquid",o.aliases=[]},50045:(e,t,n)=>{n.d(t,{default:()=>o});var a=n(25712);const o=n.n(a)()},51572:e=>{function t(e){!function(e){function t(e,t){return"___"+e.toUpperCase()+t+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(n,a,o,i){if(n.language===a){var r=n.tokenStack=[];n.code=n.code.replace(o,(function(e){if("function"===typeof i&&!i(e))return e;for(var o,l=r.length;-1!==n.code.indexOf(o=t(a,l));)++l;return r[l]=e,o})),n.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(n,a){if(n.language===a&&n.tokenStack){n.grammar=e.languages[a];var o=0,i=Object.keys(n.tokenStack);!function r(l){for(var s=0;s=i.length);s++){var c=l[s];if("string"===typeof c||c.content&&"string"===typeof c.content){var u=i[o],p=n.tokenStack[u],d="string"===typeof c?c:c.content,g=t(a,u),m=d.indexOf(g);if(m>-1){++o;var f=d.substring(0,m),_=new e.Token(a,e.tokenize(p,n.grammar),"language-"+a,p),b=d.substring(m+g.length),k=[];f&&k.push.apply(k,r([f])),k.push(_),b&&k.push.apply(k,r([b])),"string"===typeof c?l.splice.apply(l,[s,1].concat(k)):c.content=k}}else c.content&&r(c.content)}return l}(n.tokens)}}}})}(e)}e.exports=t,t.displayName="markupTemplating",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/50245.1623217b.chunk.js b/ydb/core/viewer/monitoring/static/js/50245.1623217b.chunk.js new file mode 100644 index 000000000000..00fe325456a1 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/50245.1623217b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[50245],{50245:(e,t,n)=>{n.d(t,{registerYQLCompletionItemProvider:()=>J});var i=n(80781),s=n(92727);const o={suggestTemplates:0,suggestPragmas:1,suggestEntity:2,suggestAllColumns:3,suggestColumns:4,suggestColumnAliases:5,suggestVariables:6,suggestTableIndexes:7,suggestTableHints:8,suggestEntitySettings:9,suggestKeywords:10,suggestAggregateFunctions:11,suggestTableFunctions:12,suggestWindowFunctions:13,suggestFunctions:14,suggestSimpleTypes:15,suggestUdfs:16};function a(e){return o[e]}const r="abcdefghijklmnopqrstuvwxyz";function l(e){const t=r[e];if(t)return t;const n=Math.floor(e/26),i=e%26;return r.slice(-1).repeat(n)+r[i]}function u(e){return e.startsWith("$")}function c(e=[]){return Array.from(new Set(e))}const m=/[\s'"-/@]/;function g(e){if(e.startsWith("`")&&e.endsWith("`"))return e;let t=e;return e.match(m)&&(t=`\`${e}\``),t}function d(e){let t=0,n=e.length;return e.startsWith("`")&&(t=1),e.endsWith("`")&&(n=-1),e.slice(t,n)}function T(e,t){const n=e.slice(0,t).split("\n");return{lineNumber:n.length,column:n[n.length-1].length+1}}const p=/([^\s]+)$/;function S(e,t,n=p){const i=e.slice(0,t).match(n);return i&&i[1]?i[1]:""}const I=/([^\\/\s`]+)$/;class h{constructor({getQueryParser:e,getUdfs:t,getSimpleTypes:n,getPragmas:i,getWindowFunctions:s,getTableFunctions:o,getAggregateFunctions:a,getSimpleFunctions:r,getEntitySettings:l,fetchEntities:u,fetchEntityColumns:c}){e&&(this.getQueryParser=e),t&&(this.getUdfs=t),n&&(this.getSimpleTypes=n),i&&(this.getPragmas=i),s&&(this.getWindowFunctions=s),o&&(this.getTableFunctions=o),a&&(this.getAggregateFunctions=a),r&&(this.getSimpleFunctions=r),l&&(this.getEntitySettings=l),u&&(this.fetchEntities=u),c&&(this.fetchEntityColumns=c)}async getSuggestions(e,t){const n=await this.parseInput(e,t);let i=[],o=[],r=[],m=[],p=[],h=[],y=[],f=[],C=[],A=[],b=[];const L=function(e,t){const n=T(e,t),i=S(e,t,I);return{startColumn:n.column-i.length,startLineNumber:n.lineNumber,endColumn:n.column,endLineNumber:n.lineNumber}}(e,t),D=S(e,t);if(n.suggestSimpleTypes){const e=await this.getSimpleTypes(D);y=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.TypeParameter,detail:"Type",range:e,sortText:l(a("suggestSimpleTypes"))})))}(L,e)}if(n.suggestEntity){const e=await this.fetchEntities(D,n.suggestEntity);i=await async function(e,t,n=""){const i=null===n||void 0===n?void 0:n.startsWith("`");return t.reduce(((t,{value:n,detail:o,isDir:r})=>{const u=r?`${n}/`:n;let c;r&&!i&&(c=`\`${u}$0\``);const m=t.length;return t.push({label:u,insertText:null!==c&&void 0!==c?c:u,kind:r?s.eo.CompletionItemKind.Folder:s.eo.CompletionItemKind.Text,insertTextRules:c?s.eo.CompletionItemInsertTextRule.InsertAsSnippet:s.eo.CompletionItemInsertTextRule.None,detail:o,range:e,command:u.endsWith("/")?{id:"editor.action.triggerSuggest",title:""}:void 0,sortText:l(a("suggestEntity"))+l(m)}),t}),[])}(L,e,D)}if(n.suggestVariables&&(b=function(e,t=[]){return t.map((({name:t})=>{const n="$"+t;return{label:n,insertText:n,kind:s.eo.CompletionItemKind.Variable,detail:"Variable",range:e,sortText:l(a("suggestVariables"))}}))}(L,n.suggestVariables)),n.suggestFunctions){const e=await this.getSimpleFunctions(D);o=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Function,detail:"Function",range:e,sortText:l(a("suggestFunctions"))})))}(L,e)}if(n.suggestAggregateFunctions){const e=await this.getAggregateFunctions(D);r=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Function,detail:"Aggregate function",range:e,sortText:l(a("suggestAggregateFunctions"))})))}(L,e)}if(n.suggestWindowFunctions){const e=await this.getWindowFunctions(D);m=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Function,detail:"Window function",range:e,sortText:l(a("suggestWindowFunctions"))})))}(L,e)}if(n.suggestTableFunctions){const e=await this.getTableFunctions(D);p=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Function,detail:"Table function",range:e,sortText:l(a("suggestTableFunctions"))})))}(L,e)}if(n.suggestUdfs){const e=await this.getUdfs(D);h=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Function,detail:"UDF",range:e,sortText:l(a("suggestUdfs"))})))}(L,e)}if(n.suggestPragmas){const e=await this.getPragmas(D);f=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Module,detail:"Pragma",range:e,sortText:l(a("suggestPragmas"))})))}(L,e)}if(n.suggestEntitySettings){const e=await this.getEntitySettings(n.suggestEntitySettings);C=await async function(e,t=[]){return t.map((t=>({label:t,insertText:t,kind:s.eo.CompletionItemKind.Property,detail:"Setting",range:e,sortText:l(a("suggestEntitySettings"))})))}(L,e)}const F=function(e,t=[]){return t.map((t=>({label:t.value,insertText:t.value,kind:s.eo.CompletionItemKind.Keyword,detail:"Keyword",range:e,sortText:l(a("suggestKeywords"))})))}(L,n.suggestKeywords),v=await function(e,t=[]){return t.map((t=>({label:t.name,insertText:t.name,kind:s.eo.CompletionItemKind.Variable,detail:"Column alias",range:e,sortText:l(a("suggestColumnAliases"))})))}(L,n.suggestColumnAliases);if(n.suggestColumns){const e=function(e){var t;return c(null===(t=null===e||void 0===e?void 0:e.tables)||void 0===t?void 0:t.map((e=>e.name))).filter((e=>!u(e)))}(n.suggestColumns),t=await this.fetchEntityColumns(e);A=await async function(e,t,n,i){var o;if(!(null===t||void 0===t?void 0:t.tables))return[];const r=[],m=t.all?[]:void 0,T=t.tables.length>1,p=c(t.tables.map((e=>e.name))).filter(u),S=[];p.length&&p.forEach((e=>{var t,i,s,o;const a=null!==(o=null===(s=null===(i=null===(t=null===n||void 0===n?void 0:n.find((t=>e.slice(1)===t.name)))||void 0===t?void 0:t.value)||void 0===i?void 0:i.columns)||void 0===s?void 0:s.map((t=>({name:t,parent:e}))))&&void 0!==o?o:[];S.push(...a)}));const I=t.tables.reduce(((e,t)=>{const n=t.columns;return n&&e.push(...n.map((e=>({name:e,parent:t.name})))),e}),[]),h=null===(o=t.tables)||void 0===o?void 0:o.reduce(((e,t)=>{var n;const i=d(t.name),s=null!==(n=e[i])&&void 0!==n?n:[];return t.alias&&s.push(t.alias),e[i]=s,e}),{});if([...i,...S,...I].forEach((t=>{const n=g(t.name),i=h[d(t.parent)],o=r.length;if(null===i||void 0===i?void 0:i.length)i.forEach((i=>{const u=`${i}.${n}`;r.push({label:{label:u,description:t.detail},insertText:u,kind:s.eo.CompletionItemKind.Variable,detail:"Column",range:e,sortText:l(a("suggestColumns"))+l(o)}),null===m||void 0===m||m.push(u)}));else{let i=n;T&&(i=`${g(t.parent)}.${n}`),r.push({label:{label:i,description:t.detail},insertText:i,kind:s.eo.CompletionItemKind.Variable,detail:"Column",range:e,sortText:l(a("suggestColumns"))+l(o)}),null===m||void 0===m||m.push(i)}})),m&&m.length>1){const t=m.join(", ");r.push({label:t,insertText:t,kind:s.eo.CompletionItemKind.Variable,range:e,sortText:l(a("suggestAllColumns"))})}return r}(L,n.suggestColumns,n.suggestVariables,t)}return[...i,...o,...m,...p,...h,...y,...f,...v,...A,...F,...r,...C,...b]}async parseInput(e,t){const n=T(e,t);return(await this.getQueryParser())(e,{line:n.lineNumber,column:n.column})}async getQueryParser(){const{parseYqlQuery:e}=await Promise.resolve().then(n.bind(n,41614));return e}async getSimpleTypes(e){return[]}async getUdfs(e){return[]}async getPragmas(e){return[]}async getWindowFunctions(e){return[]}async getTableFunctions(e){return[]}async getAggregateFunctions(e){return[]}async getSimpleFunctions(e){return[]}async getEntitySettings(e){return[]}async fetchEntities(e,t){return[]}async fetchEntityColumns(e){return[]}}function y(e={}){const t=new h(e);return async(e,n,i,s)=>({suggestions:await t.getSuggestions(e.getValue(),e.getOffsetAt(n))})}const f=new Map;function C(e,t,n){!function(e){const t=f.get(e);t&&t.dispose()}(e);const s=i.languages.registerCompletionItemProvider(e,{triggerCharacters:t,provideCompletionItems:y(n)});f.set(e,s)}var A=n(23195);const b=["Text","Bytes","String","Bool","Int32","Uint32","Int64","Uint64","Float","Double","Void","Yson","Utf8","Unit","Json","Date","Datetime","Timestamp","Interval","Date32","Datetime64","Timestamp64","Interval64","TzDate32","TzDatetime64","TzTimestamp64","Null","Int8","Uint8","Int16","Uint16","TzDate","TzDatetime","TzTimestamp","Uuid","EmptyList","EmptyDict","JsonDocument","DyNumber"],L=["CAST","COALESCE","LENGTH","LEN","SUBSTRING","FIND","RFIND","StartsWith","EndsWith","IF","NANVL","Random","RandomNumber","RandomUuid","CurrentUtcDate","CurrentUtcDatetime","CurrentUtcTimestamp","CurrentTzDate","CurrentTzDatetime","CurrentTzTimestamp","AddTimezone","RemoveTimezone","MAX_OF","MIN_OF","GREATEST","LEAST","AsTuple","AsStruct","AsList","AsDict","AsSet","AsListStrict","AsDictStrict","AsSetStrict","Variant","AsVariant","Enum","AsEnum","AsTagged","Untag","TableRow","JoinTableRow","Ensure","EnsureType","EnsureConvertibleTo","ToBytes","FromBytes","ByteAt","TestBit","ClearBit","SetBit","FlipBit","Abs","Just","Unwrap","Nothing","Callable","StaticMap","StaticZip","ListCreate","AsListStrict","ListLength","ListHasItems","ListCollect","ListSort","ListSortAsc","ListSortDesc","ListExtend","ListExtendStrict","ListUnionAll","ListZip","ListZipAll","ListEnumerate","ListReverse","ListSkip","ListTake","ListIndexOf","ListMap","ListFilter","ListFlatMap","ListNotNull","ListFlatten","ListUniq","ListAny","ListAll","ListHas","ListHead","ListLast","ListMin","ListMax","ListSum","ListAvg","ListFold","ListFold1","ListFoldMap","ListFold1Map","ListFromRange","ListReplicate","ListConcat","ListExtract","ListTakeWhile","ListSkipWhile","ListAggregate","ToDict","ToMultiDict","ToSet","DictCreate","SetCreate","DictLength","DictHasItems","DictItems","DictKeys","DictPayloads","DictLookup","DictContains","DictAggregate","SetIsDisjoint","SetIntersection","SetIncludes","SetUnion","SetDifference","SetSymmetricDifference","TryMember","ExpandStruct","AddMember","RemoveMember","ForceRemoveMember","ChooseMembers","RemoveMembers","ForceRemoveMembers","CombineMembers","FlattenMembers","StructMembers","RenameMembers","ForceRenameMembers","GatherMembers","SpreadMembers","ForceSpreadMembers","FormatType","ParseType","TypeOf","InstanceOf","DataType","OptionalType","ListType","StreamType","DictType","TupleType","StructType","VariantType","ResourceType","CallableType","GenericType","UnitType","VoidType","OptionalItemType","ListItemType","StreamItemType","DictKeyType","DictPayloadType","TupleElementType","StructMemberType","CallableResultType","CallableArgumentType","VariantUnderlyingType","JSON_EXISTS","JSON_VALUE","JSON_QUERY"],D=["COUNT","MIN","MAX","SUM","AVG","COUNT_IF","SUM_IF","AVG_IF","SOME","CountDistinctEstimate","HyperLogLog","AGGREGATE_LIST","AGGREGATE_LIST_DISTINCT","AGG_LIST","AGG_LIST_DISTINCT","MAX_BY","MIN_BY","AGGREGATE_BY","MULTI_AGGREGATE_BY","TOP","BOTTOM","TOP_BY","BOTTOM_BY","TOPFREQ","MODE","STDDEV","VARIANCE","CORRELATION","COVARIANCE","PERCENTILE","MEDIAN","HISTOGRAM","LogarithmicHistogram","LogHistogram","LinearHistogram","BOOL_AND","BOOL_OR","BOOL_XOR","BIT_AND","BIT_OR","BIT_XOR","SessionStart"],F=Object.entries({DateTime:["EndOfMonth","Format","FromMicroseconds","FromMilliseconds","FromSeconds","GetDayOfMonth","GetDayOfWeek","GetDayOfWeekName","GetDayOfYear","GetHour","GetMicrosecondOfSecond","GetMillisecondOfSecond","GetMinute","GetMonth","GetMonthName","GetSecond","GetTimezoneId","GetTimezoneName","GetWeekOfYear","GetWeekOfYearIso8601","GetYear","IntervalFromDays","IntervalFromHours","IntervalFromMicroseconds","IntervalFromMilliseconds","IntervalFromMinutes","IntervalFromSeconds","MakeDate","MakeDatetime","MakeTimestamp","MakeTzDate","MakeTzDatetime","MakeTzTimestamp","Parse","ParseHttp","ParseIso8601","ParseRfc822","ParseX509","ShiftMonths","ShiftQuarters","ShiftYears","Split","StartOf","StartOfDay","StartOfMonth","StartOfQuarter","StartOfWeek","StartOfYear","TimeOfDay","ToDays","ToHours","ToMicroseconds","ToMilliseconds","ToMinutes","ToSeconds","Update"],Dsv:["Parse","ReadRecord","Serialize"],String:["AsciiToLower","AsciiToTitle","AsciiToUpper","Base32Decode","Base32Encode","Base32StrictDecode","Base64Decode","Base64Encode","Base64EncodeUrl","Base64StrictDecode","Bin","BinText","CgiEscape","CgiUnescape","Collapse","CollapseText","Contains","DecodeHtml","EncodeHtml","EndsWith","EndsWithIgnoreCase","EscapeC","FromByteList","HasPrefix","HasPrefixIgnoreCase","HasSuffix","HasSuffixIgnoreCase","Hex","HexDecode","HexEncode","HexText","HumanReadableBytes","HumanReadableDuration","HumanReadableQuantity","IsAscii","IsAsciiAlnum","IsAsciiAlpha","IsAsciiDigit","IsAsciiHex","IsAsciiLower","IsAsciiSpace","IsAsciiUpper","JoinFromList","LeftPad","LevensteinDistance","Prec","RemoveAll","RemoveFirst","RemoveLast","ReplaceAll","ReplaceFirst","ReplaceLast","RightPad","SBin","SHex","SplitToList","StartsWith","StartsWithIgnoreCase","Strip","ToByteList","UnescapeC"],Unicode:["Find","Fold","FromCodePointList","GetLength","IsAlnum","IsAlpha","IsAscii","IsDigit","IsHex","IsLower","IsSpace","IsUnicodeSet","IsUpper","IsUtf","JoinFromList","LevensteinDistance","Normalize","NormalizeNFC","NormalizeNFD","NormalizeNFKC","NormalizeNFKD","RFind","RemoveAll","RemoveFirst","RemoveLast","ReplaceAll","ReplaceFirst","ReplaceLast","Reverse","SplitToList","Strip","Substring","ToCodePointList","ToLower","ToTitle","ToUint64","ToUpper","Translit","TryToUint64"],Url:["BuildQueryString","CanBePunycodeHostName","CutQueryStringAndFragment","CutScheme","CutWWW","CutWWW2","Decode","Encode","ForceHostNameToPunycode","ForcePunycodeToHostName","GetCGIParam","GetDomain","GetDomainLevel","GetFragment","GetHost","GetHostPort","GetOwner","GetPath","GetPort","GetScheme","GetSchemeHost","GetSchemeHostPort","GetSignificantDomain","GetTLD","GetTail","HostNameToPunycode","IsAllowedByRobotsTxt","IsKnownTLD","IsWellKnownTLD","Normalize","NormalizeWithDefaultHttpScheme","Parse","PunycodeToHostName","QueryStringToDict","QueryStringToList"],Yson:["Attributes","Contains","ConvertTo","ConvertToBool","ConvertToBoolDict","ConvertToBoolList","ConvertToDict","ConvertToDouble","ConvertToDoubleDict","ConvertToDoubleList","ConvertToInt64","ConvertToInt64Dict","ConvertToInt64List","ConvertToList","ConvertToString","ConvertToStringDict","ConvertToStringList","ConvertToUint64","ConvertToUint64Dict","ConvertToUint64List","Equals","From","GetHash","GetLength","IsBool","IsDict","IsDouble","IsEntity","IsInt64","IsList","IsString","IsUint64","Lookup","LookupBool","LookupDict","LookupDouble","LookupInt64","LookupList","LookupString","LookupUint64","Options","Parse","ParseJson","ParseJsonDecodeUtf8","Serialize","SerializeJson","SerializePretty","SerializeText","WithAttributes","YPath","YPathBool","YPathDict","YPathDouble","YPathInt64","YPathList","YPathString","YPathUint64"],HyperLogLog:["AddValue","Create","Deserialize","GetResult","Merge","Serialize"],Hyperscan:["BacktrackingGrep","BacktrackingMatch","Capture","Grep","Match","MultiGrep","MultiMatch","Replace"],Ip:["ConvertToIPv6","FromString","GetSubnet","GetSubnetByMask","IsEmbeddedIPv4","IsIPv4","IsIPv6","SubnetFromString","SubnetMatch","SubnetToString","ToFixedIPv6String","ToString"],Json:["BoolAsJsonNode","CompilePath","DoubleAsJsonNode","JsonAsJsonNode","JsonDocumentSqlExists","JsonDocumentSqlQuery","JsonDocumentSqlQueryConditionalWrap","JsonDocumentSqlQueryWrap","JsonDocumentSqlTryExists","JsonDocumentSqlValueBool","JsonDocumentSqlValueConvertToUtf8","JsonDocumentSqlValueInt64","JsonDocumentSqlValueNumber","JsonDocumentSqlValueUtf8","Parse","Serialize","SerializeToJsonDocument","SqlExists","SqlQuery","SqlQueryConditionalWrap","SqlQueryWrap","SqlTryExists","SqlValueBool","SqlValueConvertToUtf8","SqlValueInt64","SqlValueNumber","SqlValueUtf8","Utf8AsJsonNode"],Math:["Abs","Acos","Asin","Asinh","Atan","Atan2","Cbrt","Ceil","Cos","Cosh","E","Eps","Erf","ErfInv","ErfcInv","Exp","Exp2","Fabs","Floor","Fmod","FuzzyEquals","Hypot","IsFinite","IsInf","IsNaN","Ldexp","Lgamma","Log","Log10","Log2","Mod","NearbyInt","Pi","Pow","Rem","Remainder","Rint","Round","RoundDownward","RoundToNearest","RoundTowardZero","RoundUpward","Sigmoid","Sin","Sinh","Sqrt","Tan","Tanh","Tgamma","Trunc"],Pire:["Capture","Grep","Match","MultiGrep","MultiMatch","Replace"],Re2:["Capture","Count","Escape","FindAndConsume","Grep","Match","Options","PatternFromLike","Replace"],Re2posix:["Capture","Count","Escape","FindAndConsume","Grep","Match","Options","PatternFromLike","Replace"],Digest:["Argon2","Blake2B","CityHash","CityHash128","Crc32c","Crc64","FarmHashFingerprint","FarmHashFingerprint128","FarmHashFingerprint2","FarmHashFingerprint32","FarmHashFingerprint64","Fnv32","Fnv64","HighwayHash","IntHash64","Md5HalfMix","Md5Hex","Md5Raw","MurMurHash","MurMurHash2A","MurMurHash2A32","MurMurHash32","NumericHash","Sha1","Sha256","SipHash","SuperFastHash","XXH3","XXH3_128"],Histogram:["CalcLowerBound","CalcLowerBoundSafe","CalcUpperBound","CalcUpperBoundSafe","GetSumAboveBound","GetSumBelowBound","GetSumInRange","Normalize","Print","ToCumulativeDistributionFunction"]}).reduce(((e,[t,n])=>{const i=n.map((e=>`${t}::${e}`));return e.concat(i)}),[]),v=["ROW_NUMBER","LAG","LEAD","FIRST_VALUE","LAST_VALUE","RANK","DENSE_RANK","SessionState"],E=[],R=["TablePathPrefix","Warning"],M={table:["AUTO_PARTITIONING_BY_SIZE","AUTO_PARTITIONING_PARTITION_SIZE_MB","AUTO_PARTITIONING_BY_LOAD","AUTO_PARTITIONING_MIN_PARTITIONS_COUNT","AUTO_PARTITIONING_MAX_PARTITIONS_COUNT","UNIFORM_PARTITIONS","READ_REPLICAS_SETTINGS","TTL","KEY_BLOOM_FILTER","STORE"],view:["security_invoker"],topic:["min_active_partitions","partition_count_limit","retention_period","retention_storage_mb","partition_write_speed_bytes_per_second","partition_write_burst_bytes","metering_mode"],object:[],user:[],group:[],externalDataSource:[],externalTable:[],tableStore:[],replication:["ENDPOINT","DATABASE","USER","PASSWORD"],tableIndex:[],topicConsumer:["important","read_from"]},N={externalDataSource:["external_data_source"],externalTable:["external_table"],replication:["replication"],table:["table","column_table"],tableStore:["column_store"],topic:["pers_queue_group"],view:["view"],tableIndex:["table_index","index"]},P=["dir","unknown","ext_sub_domain"],_=["dir","ext_sub_domain"];function x(e){let t=0,n=e.length;return e.startsWith("`")&&(t=1),e.endsWith("`")&&(n=-1),e.slice(t,n)}function O(e){return e.startsWith("/")?e.slice(1):e}async function w(){return L}async function G(){return v}async function U(){return E}async function B(){return D}async function H(){return R}async function k(e){return M[e]}async function W(){return F}async function V(){return b}function z(e){const{PKIndex:t,NotNull:n,Default:i}=e,s=[];void 0!==t&&s.push(`PK${t}`),n&&s.push("NN"),i&&s.push("Default");return s.length?s.join(", "):""}function K(e,t){var n;return null!==(n=e.map((e=>{let n=x(e);return n.endsWith("/")||(n=`${n}/`),function(e="",t){const n=x(e);if(!n.startsWith("/"))return n;let i=O(n);const s=O(t);return i.startsWith(s)&&(i=i.slice(s.length)),O(i)}(n,t)})))&&void 0!==n?n:[]}function J(e){C(A.l,[" ",".","`","(","/"],{fetchEntities:async(t,n)=>{var i;const s=await window.api.viewer.autocomplete({database:e,prefix:x(t),limit:1e3});if(!s.Success||!s.Result.Entities)return[];const o=function(e,t){const n=t.reduce(((e,t)=>{const n=N[t];return n&&n.forEach((t=>e.add(t))),e}),new Set(P));return null===e||void 0===e?void 0:e.filter((({Type:e})=>n.has(e)))}(s.Result.Entities,n);return null!==(i=null===o||void 0===o?void 0:o.map((({Name:e,Type:t})=>{return{value:e,detail:t,isDir:(n=t,_.includes(n))};var n})))&&void 0!==i?i:[]},fetchEntityColumns:async t=>{let n=[];const i=K(t,e),s=await window.api.viewer.autocomplete({database:e,table:i,limit:1e3});var o;s.Success&&(n=null!==(o=s.Result.Entities)&&void 0!==o?o:[]);const a=[];return n.forEach((e=>{(function(e){return"column"===e.Type})(e)&&a.push({name:e.Name,detail:z(e),parent:e.Parent})})),a},getEntitySettings:k,getPragmas:H,getSimpleFunctions:w,getAggregateFunctions:B,getTableFunctions:U,getWindowFunctions:G,getUdfs:W,getSimpleTypes:V})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5027.9e6325ef.chunk.js b/ydb/core/viewer/monitoring/static/js/5027.9e6325ef.chunk.js deleted file mode 100644 index 385feb54c024..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5027.9e6325ef.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5027],{85027:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-ca",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"YYYY-MM-DD",LL:"MMMM D, YYYY",LLL:"MMMM D, YYYY h:mm A",LLLL:"dddd, MMMM D, YYYY h:mm A"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5047.ebc9f1b2.chunk.js b/ydb/core/viewer/monitoring/static/js/5047.ebc9f1b2.chunk.js deleted file mode 100644 index 7b150570cb7b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5047.ebc9f1b2.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5047],{85047:function(e,t,r){e.exports=function(e){"use strict";function t(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var r=t(e);function n(e){return e>1&&e<5&&1!=~~(e/10)}function a(e,t,r,a){var s=e+" ";switch(r){case"s":return t||a?"p\xe1r sek\xfand":"p\xe1r sekundami";case"m":return t?"min\xfata":a?"min\xfatu":"min\xfatou";case"mm":return t||a?s+(n(e)?"min\xfaty":"min\xfat"):s+"min\xfatami";case"h":return t?"hodina":a?"hodinu":"hodinou";case"hh":return t||a?s+(n(e)?"hodiny":"hod\xedn"):s+"hodinami";case"d":return t||a?"de\u0148":"d\u0148om";case"dd":return t||a?s+(n(e)?"dni":"dn\xed"):s+"d\u0148ami";case"M":return t||a?"mesiac":"mesiacom";case"MM":return t||a?s+(n(e)?"mesiace":"mesiacov"):s+"mesiacmi";case"y":return t||a?"rok":"rokom";case"yy":return t||a?s+(n(e)?"roky":"rokov"):s+"rokmi"}}var s={name:"sk",weekdays:"nede\u013ea_pondelok_utorok_streda_\u0161tvrtok_piatok_sobota".split("_"),weekdaysShort:"ne_po_ut_st_\u0161t_pi_so".split("_"),weekdaysMin:"ne_po_ut_st_\u0161t_pi_so".split("_"),months:"janu\xe1r_febru\xe1r_marec_apr\xedl_m\xe1j_j\xfan_j\xfal_august_september_okt\xf3ber_november_december".split("_"),monthsShort:"jan_feb_mar_apr_m\xe1j_j\xfan_j\xfal_aug_sep_okt_nov_dec".split("_"),weekStart:1,yearStart:4,ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd D. MMMM YYYY H:mm",l:"D. M. YYYY"},relativeTime:{future:"za %s",past:"pred %s",s:a,m:a,mm:a,h:a,hh:a,d:a,dd:a,M:a,MM:a,y:a,yy:a}};return r.default.locale(s,null,!0),s}(r(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5050.ffa3921f.chunk.js b/ydb/core/viewer/monitoring/static/js/5050.ffa3921f.chunk.js deleted file mode 100644 index 0a46c2487410..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5050.ffa3921f.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5050.ffa3921f.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5050],{95050:(e,n,o)=>{o.r(n),o.d(n,{conf:()=>s,language:()=>t});var s={comments:{lineComment:"--",blockComment:["--[[","]]"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},t={defaultToken:"",tokenPostfix:".lua",keywords:["and","break","do","else","elseif","end","false","for","function","goto","if","in","local","nil","not","or","repeat","return","then","true","until","while"],brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.array",open:"[",close:"]"},{token:"delimiter.parenthesis",open:"(",close:")"}],operators:["+","-","*","/","%","^","#","==","~=","<=",">=","<",">","=",";",":",",",".","..","..."],symbols:/[=>{t.d(n,{default:()=>i});var a=t(99460);const i=t.n(a)()},99460:e=>{function n(e){!function(e){var n={pattern:/[\s\S]+/,inside:null};e.languages.v=e.languages.extend("clike",{string:{pattern:/r?(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,alias:"quoted-string",greedy:!0,inside:{interpolation:{pattern:/((?:^|[^\\])(?:\\{2})*)\$(?:\{[^{}]*\}|\w+(?:\.\w+(?:\([^\(\)]*\))?|\[[^\[\]]+\])*)/,lookbehind:!0,inside:{"interpolation-variable":{pattern:/^\$\w[\s\S]*$/,alias:"variable"},"interpolation-punctuation":{pattern:/^\$\{|\}$/,alias:"punctuation"},"interpolation-expression":n}}}},"class-name":{pattern:/(\b(?:enum|interface|struct|type)\s+)(?:C\.)?\w+/,lookbehind:!0},keyword:/(?:\b(?:__global|as|asm|assert|atomic|break|chan|const|continue|defer|else|embed|enum|fn|for|go(?:to)?|if|import|in|interface|is|lock|match|module|mut|none|or|pub|return|rlock|select|shared|sizeof|static|struct|type(?:of)?|union|unsafe)|\$(?:else|for|if)|#(?:flag|include))\b/,number:/\b(?:0x[a-f\d]+(?:_[a-f\d]+)*|0b[01]+(?:_[01]+)*|0o[0-7]+(?:_[0-7]+)*|\d+(?:_\d+)*(?:\.\d+(?:_\d+)*)?)\b/i,operator:/~|\?|[*\/%^!=]=?|\+[=+]?|-[=-]?|\|[=|]?|&(?:=|&|\^=?)?|>(?:>=?|=)?|<(?:<=?|=|-)?|:=|\.\.\.?/,builtin:/\b(?:any(?:_float|_int)?|bool|byte(?:ptr)?|charptr|f(?:32|64)|i(?:8|16|64|128|nt)|rune|size_t|string|u(?:16|32|64|128)|voidptr)\b/}),n.inside=e.languages.v,e.languages.insertBefore("v","string",{char:{pattern:/`(?:\\`|\\?[^`]{1,2})`/,alias:"rune"}}),e.languages.insertBefore("v","operator",{attribute:{pattern:/(^[\t ]*)\[(?:deprecated|direct_array_access|flag|inline|live|ref_only|typedef|unsafe_fn|windows_stdcall)\]/m,lookbehind:!0,alias:"annotation",inside:{punctuation:/[\[\]]/,keyword:/\w+/}},generic:{pattern:/<\w+>(?=\s*[\)\{])/,inside:{punctuation:/[<>]/,"class-name":/\w+/}}}),e.languages.insertBefore("v","function",{"generic-function":{pattern:/\b\w+\s*<\w+>(?=\()/,inside:{function:/^\w+/,generic:{pattern:/<\w+>/,inside:e.languages.v.generic.inside}}}})}(e)}e.exports=n,n.displayName="v",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/51094.f421b808.chunk.js b/ydb/core/viewer/monitoring/static/js/51094.f421b808.chunk.js new file mode 100644 index 000000000000..ae507d46759d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51094.f421b808.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 51094.f421b808.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51094],{51094:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>a,language:()=>c});var o=e=>`\\b${e}\\b`,i=e=>`(?!${e})`,r=o("[_a-zA-Z][_a-zA-Z0-9]*"),s=o("[_a-zA-Z-0-9]+"),a={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"/**",close:" */",notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],indentationRules:{decreaseIndentPattern:new RegExp("^((?!.*?/\\*).*\\*/)?\\s*[\\}\\]].*$"),increaseIndentPattern:new RegExp("^((?!//).)*(\\{([^}\"'`/]*|(\\t|[ ])*//.*)|\\([^)\"'`/]*|\\[[^\\]\"'`/]*)$"),unIndentedLinePattern:new RegExp("^(\\t|[ ])*[ ]\\*[^/]*\\*/\\s*$|^(\\t|[ ])*[ ]\\*/\\s*$|^(\\t|[ ])*[ ]\\*([ ]([^\\*]|\\*(?!/))*)?$")}},c={defaultToken:"",tokenPostfix:".tsp",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],symbols:/[=:;<>]+/,keywords:["import","model","scalar","namespace","op","interface","union","using","is","extends","enum","alias","return","void","if","else","projection","dec","extern","fn"],namedLiterals:["true","false","null","unknown","never"],escapes:'\\\\(u{[0-9A-Fa-f]+}|n|r|t|\\\\|"|\\${)',tokenizer:{root:[{include:"@expression"},{include:"@whitespace"}],stringVerbatim:[{regex:'(|"|"")[^"]',action:{token:"string"}},{regex:`"""${i('"')}`,action:{token:"string",next:"@pop"}}],stringLiteral:[{regex:"\\${",action:{token:"delimiter.bracket",next:"@bracketCounting"}},{regex:'[^\\\\"$]+',action:{token:"string"}},{regex:"@escapes",action:{token:"string.escape"}},{regex:"\\\\.",action:{token:"string.escape.invalid"}},{regex:'"',action:{token:"string",next:"@pop"}}],bracketCounting:[{regex:"{",action:{token:"delimiter.bracket",next:"@bracketCounting"}},{regex:"}",action:{token:"delimiter.bracket",next:"@pop"}},{include:"@expression"}],comment:[{regex:"[^\\*]+",action:{token:"comment"}},{regex:"\\*\\/",action:{token:"comment",next:"@pop"}},{regex:"[\\/*]",action:{token:"comment"}}],whitespace:[{regex:"[ \\t\\r\\n]"},{regex:"\\/\\*",action:{token:"comment",next:"@comment"}},{regex:"\\/\\/.*$",action:{token:"comment"}}],expression:[{regex:'"""',action:{token:"string",next:"@stringVerbatim"}},{regex:`"${i('""')}`,action:{token:"string",next:"@stringLiteral"}},{regex:"[0-9]+",action:{token:"number"}},{regex:r,action:{cases:{"@keywords":{token:"keyword"},"@namedLiterals":{token:"keyword"},"@default":{token:"identifier"}}}},{regex:`@${r}`,action:{token:"tag"}},{regex:`#${s}`,action:{token:"directive"}}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5050.ffa3921f.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/51094.f421b808.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5050.ffa3921f.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/51094.f421b808.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/51159.314cef1d.chunk.js b/ydb/core/viewer/monitoring/static/js/51159.314cef1d.chunk.js new file mode 100644 index 000000000000..16cebf806dfc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51159.314cef1d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51159],{30390:e=>{function n(e){!function(e){e.languages.puppet={heredoc:[{pattern:/(@\("([^"\r\n\/):]+)"(?:\/[nrts$uL]*)?\).*(?:\r?\n|\r))(?:.*(?:\r?\n|\r(?!\n)))*?[ \t]*(?:\|[ \t]*)?(?:-[ \t]*)?\2/,lookbehind:!0,alias:"string",inside:{punctuation:/(?=\S).*\S(?= *$)/}},{pattern:/(@\(([^"\r\n\/):]+)(?:\/[nrts$uL]*)?\).*(?:\r?\n|\r))(?:.*(?:\r?\n|\r(?!\n)))*?[ \t]*(?:\|[ \t]*)?(?:-[ \t]*)?\2/,lookbehind:!0,greedy:!0,alias:"string",inside:{punctuation:/(?=\S).*\S(?= *$)/}},{pattern:/@\("?(?:[^"\r\n\/):]+)"?(?:\/[nrts$uL]*)?\)/,alias:"string",inside:{punctuation:{pattern:/(\().+?(?=\))/,lookbehind:!0}}}],"multiline-comment":{pattern:/(^|[^\\])\/\*[\s\S]*?\*\//,lookbehind:!0,greedy:!0,alias:"comment"},regex:{pattern:/((?:\bnode\s+|[~=\(\[\{,]\s*|[=+]>\s*|^\s*))\/(?:[^\/\\]|\\[\s\S])+\/(?:[imx]+\b|\B)/,lookbehind:!0,greedy:!0,inside:{"extended-regex":{pattern:/^\/(?:[^\/\\]|\\[\s\S])+\/[im]*x[im]*$/,inside:{comment:/#.*/}}}},comment:{pattern:/(^|[^\\])#.*/,lookbehind:!0,greedy:!0},string:{pattern:/(["'])(?:\$\{(?:[^'"}]|(["'])(?:(?!\2)[^\\]|\\[\s\S])*\2)+\}|\$(?!\{)|(?!\1)[^\\$]|\\[\s\S])*\1/,greedy:!0,inside:{"double-quoted":{pattern:/^"[\s\S]*"$/,inside:{}}}},variable:{pattern:/\$(?:::)?\w+(?:::\w+)*/,inside:{punctuation:/::/}},"attr-name":/(?:\b\w+|\*)(?=\s*=>)/,function:[{pattern:/(\.)(?!\d)\w+/,lookbehind:!0},/\b(?:contain|debug|err|fail|include|info|notice|realize|require|tag|warning)\b|\b(?!\d)\w+(?=\()/],number:/\b(?:0x[a-f\d]+|\d+(?:\.\d+)?(?:e-?\d+)?)\b/i,boolean:/\b(?:false|true)\b/,keyword:/\b(?:application|attr|case|class|consumes|default|define|else|elsif|function|if|import|inherits|node|private|produces|type|undef|unless)\b/,datatype:{pattern:/\b(?:Any|Array|Boolean|Callable|Catalogentry|Class|Collection|Data|Default|Enum|Float|Hash|Integer|NotUndef|Numeric|Optional|Pattern|Regexp|Resource|Runtime|Scalar|String|Struct|Tuple|Type|Undef|Variant)\b/,alias:"symbol"},operator:/=[=~>]?|![=~]?|<(?:<\|?|[=~|-])?|>[>=]?|->?|~>|\|>?>?|[*\/%+?]|\b(?:and|in|or)\b/,punctuation:/[\[\]{}().,;]|:+/};var n=[{pattern:/(^|[^\\])\$\{(?:[^'"{}]|\{[^}]*\}|(["'])(?:(?!\2)[^\\]|\\[\s\S])*\2)+\}/,lookbehind:!0,inside:{"short-variable":{pattern:/(^\$\{)(?!\w+\()(?:::)?\w+(?:::\w+)*/,lookbehind:!0,alias:"variable",inside:{punctuation:/::/}},delimiter:{pattern:/^\$/,alias:"variable"},rest:e.languages.puppet}},{pattern:/(^|[^\\])\$(?:::)?\w+(?:::\w+)*/,lookbehind:!0,alias:"variable",inside:{punctuation:/::/}}];e.languages.puppet.heredoc[0].inside.interpolation=n,e.languages.puppet.string.inside["double-quoted"].inside.interpolation=n}(e)}e.exports=n,n.displayName="puppet",n.aliases=[]},51159:(e,n,t)=>{t.d(n,{default:()=>i});var a=t(30390);const i=t.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/51255.beb93f73.chunk.js b/ydb/core/viewer/monitoring/static/js/51255.beb93f73.chunk.js new file mode 100644 index 000000000000..7c78dd6ffa08 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51255.beb93f73.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51255],{7208:E=>{function T(E){E.languages.basic={comment:{pattern:/(?:!|REM\b).+/i,inside:{keyword:/^REM/i}},string:{pattern:/"(?:""|[!#$%&'()*,\/:;<=>?^\w +\-.])*"/,greedy:!0},number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:E[+-]?\d+)?/i,keyword:/\b(?:AS|BEEP|BLOAD|BSAVE|CALL(?: ABSOLUTE)?|CASE|CHAIN|CHDIR|CLEAR|CLOSE|CLS|COM|COMMON|CONST|DATA|DECLARE|DEF(?: FN| SEG|DBL|INT|LNG|SNG|STR)|DIM|DO|DOUBLE|ELSE|ELSEIF|END|ENVIRON|ERASE|ERROR|EXIT|FIELD|FILES|FOR|FUNCTION|GET|GOSUB|GOTO|IF|INPUT|INTEGER|IOCTL|KEY|KILL|LINE INPUT|LOCATE|LOCK|LONG|LOOP|LSET|MKDIR|NAME|NEXT|OFF|ON(?: COM| ERROR| KEY| TIMER)?|OPEN|OPTION BASE|OUT|POKE|PUT|READ|REDIM|REM|RESTORE|RESUME|RETURN|RMDIR|RSET|RUN|SELECT CASE|SHARED|SHELL|SINGLE|SLEEP|STATIC|STEP|STOP|STRING|SUB|SWAP|SYSTEM|THEN|TIMER|TO|TROFF|TRON|TYPE|UNLOCK|UNTIL|USING|VIEW PRINT|WAIT|WEND|WHILE|WRITE)(?:\$|\b)/i,function:/\b(?:ABS|ACCESS|ACOS|ANGLE|AREA|ARITHMETIC|ARRAY|ASIN|ASK|AT|ATN|BASE|BEGIN|BREAK|CAUSE|CEIL|CHR|CLIP|COLLATE|COLOR|CON|COS|COSH|COT|CSC|DATE|DATUM|DEBUG|DECIMAL|DEF|DEG|DEGREES|DELETE|DET|DEVICE|DISPLAY|DOT|ELAPSED|EPS|ERASABLE|EXLINE|EXP|EXTERNAL|EXTYPE|FILETYPE|FIXED|FP|GO|GRAPH|HANDLER|IDN|IMAGE|IN|INT|INTERNAL|IP|IS|KEYED|LBOUND|LCASE|LEFT|LEN|LENGTH|LET|LINE|LINES|LOG|LOG10|LOG2|LTRIM|MARGIN|MAT|MAX|MAXNUM|MID|MIN|MISSING|MOD|NATIVE|NUL|NUMERIC|OF|OPTION|ORD|ORGANIZATION|OUTIN|OUTPUT|PI|POINT|POINTER|POINTS|POS|PRINT|PROGRAM|PROMPT|RAD|RADIANS|RANDOMIZE|RECORD|RECSIZE|RECTYPE|RELATIVE|REMAINDER|REPEAT|REST|RETRY|REWRITE|RIGHT|RND|ROUND|RTRIM|SAME|SEC|SELECT|SEQUENTIAL|SET|SETTER|SGN|SIN|SINH|SIZE|SKIP|SQR|STANDARD|STATUS|STR|STREAM|STYLE|TAB|TAN|TANH|TEMPLATE|TEXT|THERE|TIME|TIMEOUT|TRACE|TRANSFORM|TRUNCATE|UBOUND|UCASE|USE|VAL|VARIABLE|VIEWPORT|WHEN|WINDOW|WITH|ZER|ZONEWIDTH)(?:\$|\b)/i,operator:/<[=>]?|>=?|[+\-*\/^=&]|\b(?:AND|EQV|IMP|NOT|OR|XOR)\b/i,punctuation:/[,;:()]/}}E.exports=T,T.displayName="basic",T.aliases=[]},51255:(E,T,R)=>{R.d(T,{default:()=>N});var I=R(7208);const N=R.n(I)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/513.46a664ad.chunk.js b/ydb/core/viewer/monitoring/static/js/513.46a664ad.chunk.js deleted file mode 100644 index 8717c8b5b97e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/513.46a664ad.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[513],{90513:function(e,n,u){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var u=n(e);function r(e){return e>9?r(e%10):e}function t(e,n,u){return e+" "+function(e,n){return 2===n?function(e){return{m:"v",b:"v",d:"z"}[e.charAt(0)]+e.substring(1)}(e):e}({mm:"munutenn",MM:"miz",dd:"devezh"}[u],e)}var _={name:"br",weekdays:"Sul_Lun_Meurzh_Merc\u02bcher_Yaou_Gwener_Sadorn".split("_"),months:"Genver_C\u02bchwevrer_Meurzh_Ebrel_Mae_Mezheven_Gouere_Eost_Gwengolo_Here_Du_Kerzu".split("_"),weekStart:1,weekdaysShort:"Sul_Lun_Meu_Mer_Yao_Gwe_Sad".split("_"),monthsShort:"Gen_C\u02bchwe_Meu_Ebr_Mae_Eve_Gou_Eos_Gwe_Her_Du_Ker".split("_"),weekdaysMin:"Su_Lu_Me_Mer_Ya_Gw_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"h[e]mm A",LTS:"h[e]mm:ss A",L:"DD/MM/YYYY",LL:"D [a viz] MMMM YYYY",LLL:"D [a viz] MMMM YYYY h[e]mm A",LLLL:"dddd, D [a viz] MMMM YYYY h[e]mm A"},relativeTime:{future:"a-benn %s",past:"%s \u02bczo",s:"un nebeud segondenno\xf9",m:"ur vunutenn",mm:t,h:"un eur",hh:"%d eur",d:"un devezh",dd:t,M:"ur miz",MM:t,y:"ur bloaz",yy:function(e){switch(r(e)){case 1:case 3:case 4:case 5:case 9:return e+" bloaz";default:return e+" vloaz"}}},meridiem:function(e){return e<12?"a.m.":"g.m."}};return u.default.locale(_,null,!0),_}(u(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/51400.767e472a.chunk.js b/ydb/core/viewer/monitoring/static/js/51400.767e472a.chunk.js new file mode 100644 index 000000000000..3254ac5a609c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51400.767e472a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51400],{23549:e=>{function t(e){e.languages.autohotkey={comment:[{pattern:/(^|\s);.*/,lookbehind:!0},{pattern:/(^[\t ]*)\/\*(?:[\r\n](?![ \t]*\*\/)|[^\r\n])*(?:[\r\n][ \t]*\*\/)?/m,lookbehind:!0,greedy:!0}],tag:{pattern:/^([ \t]*)[^\s,`":]+(?=:[ \t]*$)/m,lookbehind:!0},string:/"(?:[^"\n\r]|"")*"/,variable:/%\w+%/,number:/\b0x[\dA-Fa-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee]-?\d+)?/,operator:/\?|\/\/?=?|:=|\|[=|]?|&[=&]?|\+[=+]?|-[=-]?|\*[=*]?|<(?:<=?|>|=)?|>>?=?|[.^!=~]=?|\b(?:AND|NOT|OR)\b/,boolean:/\b(?:false|true)\b/,selector:/\b(?:AutoTrim|BlockInput|Break|Click|ClipWait|Continue|Control|ControlClick|ControlFocus|ControlGet|ControlGetFocus|ControlGetPos|ControlGetText|ControlMove|ControlSend|ControlSendRaw|ControlSetText|CoordMode|Critical|DetectHiddenText|DetectHiddenWindows|Drive|DriveGet|DriveSpaceFree|EnvAdd|EnvDiv|EnvGet|EnvMult|EnvSet|EnvSub|EnvUpdate|Exit|ExitApp|FileAppend|FileCopy|FileCopyDir|FileCreateDir|FileCreateShortcut|FileDelete|FileEncoding|FileGetAttrib|FileGetShortcut|FileGetSize|FileGetTime|FileGetVersion|FileInstall|FileMove|FileMoveDir|FileRead|FileReadLine|FileRecycle|FileRecycleEmpty|FileRemoveDir|FileSelectFile|FileSelectFolder|FileSetAttrib|FileSetTime|FormatTime|GetKeyState|Gosub|Goto|GroupActivate|GroupAdd|GroupClose|GroupDeactivate|Gui|GuiControl|GuiControlGet|Hotkey|ImageSearch|IniDelete|IniRead|IniWrite|Input|InputBox|KeyWait|ListHotkeys|ListLines|ListVars|Loop|Menu|MouseClick|MouseClickDrag|MouseGetPos|MouseMove|MsgBox|OnExit|OutputDebug|Pause|PixelGetColor|PixelSearch|PostMessage|Process|Progress|Random|RegDelete|RegRead|RegWrite|Reload|Repeat|Return|Run|RunAs|RunWait|Send|SendEvent|SendInput|SendMessage|SendMode|SendPlay|SendRaw|SetBatchLines|SetCapslockState|SetControlDelay|SetDefaultMouseSpeed|SetEnv|SetFormat|SetKeyDelay|SetMouseDelay|SetNumlockState|SetRegView|SetScrollLockState|SetStoreCapslockMode|SetTimer|SetTitleMatchMode|SetWinDelay|SetWorkingDir|Shutdown|Sleep|Sort|SoundBeep|SoundGet|SoundGetWaveVolume|SoundPlay|SoundSet|SoundSetWaveVolume|SplashImage|SplashTextOff|SplashTextOn|SplitPath|StatusBarGetText|StatusBarWait|StringCaseSense|StringGetPos|StringLeft|StringLen|StringLower|StringMid|StringReplace|StringRight|StringSplit|StringTrimLeft|StringTrimRight|StringUpper|Suspend|SysGet|Thread|ToolTip|Transform|TrayTip|URLDownloadToFile|WinActivate|WinActivateBottom|WinClose|WinGet|WinGetActiveStats|WinGetActiveTitle|WinGetClass|WinGetPos|WinGetText|WinGetTitle|WinHide|WinKill|WinMaximize|WinMenuSelectItem|WinMinimize|WinMinimizeAll|WinMinimizeAllUndo|WinMove|WinRestore|WinSet|WinSetTitle|WinShow|WinWait|WinWaitActive|WinWaitClose|WinWaitNotActive)\b/i,constant:/\b(?:a_ahkpath|a_ahkversion|a_appdata|a_appdatacommon|a_autotrim|a_batchlines|a_caretx|a_carety|a_computername|a_controldelay|a_cursor|a_dd|a_ddd|a_dddd|a_defaultmousespeed|a_desktop|a_desktopcommon|a_detecthiddentext|a_detecthiddenwindows|a_endchar|a_eventinfo|a_exitreason|a_fileencoding|a_formatfloat|a_formatinteger|a_gui|a_guicontrol|a_guicontrolevent|a_guievent|a_guiheight|a_guiwidth|a_guix|a_guiy|a_hour|a_iconfile|a_iconhidden|a_iconnumber|a_icontip|a_index|a_ipaddress1|a_ipaddress2|a_ipaddress3|a_ipaddress4|a_is64bitos|a_isadmin|a_iscompiled|a_iscritical|a_ispaused|a_issuspended|a_isunicode|a_keydelay|a_language|a_lasterror|a_linefile|a_linenumber|a_loopfield|a_loopfileattrib|a_loopfiledir|a_loopfileext|a_loopfilefullpath|a_loopfilelongpath|a_loopfilename|a_loopfileshortname|a_loopfileshortpath|a_loopfilesize|a_loopfilesizekb|a_loopfilesizemb|a_loopfiletimeaccessed|a_loopfiletimecreated|a_loopfiletimemodified|a_loopreadline|a_loopregkey|a_loopregname|a_loopregsubkey|a_loopregtimemodified|a_loopregtype|a_mday|a_min|a_mm|a_mmm|a_mmmm|a_mon|a_mousedelay|a_msec|a_mydocuments|a_now|a_nowutc|a_numbatchlines|a_ostype|a_osversion|a_priorhotkey|a_priorkey|a_programfiles|a_programs|a_programscommon|a_ptrsize|a_regview|a_screendpi|a_screenheight|a_screenwidth|a_scriptdir|a_scriptfullpath|a_scripthwnd|a_scriptname|a_sec|a_space|a_startmenu|a_startmenucommon|a_startup|a_startupcommon|a_stringcasesense|a_tab|a_temp|a_thisfunc|a_thishotkey|a_thislabel|a_thismenu|a_thismenuitem|a_thismenuitempos|a_tickcount|a_timeidle|a_timeidlephysical|a_timesincepriorhotkey|a_timesincethishotkey|a_titlematchmode|a_titlematchmodespeed|a_username|a_wday|a_windelay|a_windir|a_workingdir|a_yday|a_year|a_yweek|a_yyyy|clipboard|clipboardall|comspec|errorlevel|programfiles)\b/i,builtin:/\b(?:abs|acos|asc|asin|atan|ceil|chr|class|comobjactive|comobjarray|comobjconnect|comobjcreate|comobjerror|comobjflags|comobjget|comobjquery|comobjtype|comobjvalue|cos|dllcall|exp|fileexist|Fileopen|floor|format|il_add|il_create|il_destroy|instr|isfunc|islabel|IsObject|ln|log|ltrim|lv_add|lv_delete|lv_deletecol|lv_getcount|lv_getnext|lv_gettext|lv_insert|lv_insertcol|lv_modify|lv_modifycol|lv_setimagelist|mod|numget|numput|onmessage|regexmatch|regexreplace|registercallback|round|rtrim|sb_seticon|sb_setparts|sb_settext|sin|sqrt|strlen|strreplace|strsplit|substr|tan|tv_add|tv_delete|tv_get|tv_getchild|tv_getcount|tv_getnext|tv_getparent|tv_getprev|tv_getselection|tv_gettext|tv_modify|varsetcapacity|winactive|winexist|__Call|__Get|__New|__Set)\b/i,symbol:/\b(?:alt|altdown|altup|appskey|backspace|browser_back|browser_favorites|browser_forward|browser_home|browser_refresh|browser_search|browser_stop|bs|capslock|ctrl|ctrlbreak|ctrldown|ctrlup|del|delete|down|end|enter|esc|escape|f1|f10|f11|f12|f13|f14|f15|f16|f17|f18|f19|f2|f20|f21|f22|f23|f24|f3|f4|f5|f6|f7|f8|f9|home|ins|insert|joy1|joy10|joy11|joy12|joy13|joy14|joy15|joy16|joy17|joy18|joy19|joy2|joy20|joy21|joy22|joy23|joy24|joy25|joy26|joy27|joy28|joy29|joy3|joy30|joy31|joy32|joy4|joy5|joy6|joy7|joy8|joy9|joyaxes|joybuttons|joyinfo|joyname|joypov|joyr|joyu|joyv|joyx|joyy|joyz|lalt|launch_app1|launch_app2|launch_mail|launch_media|lbutton|lcontrol|lctrl|left|lshift|lwin|lwindown|lwinup|mbutton|media_next|media_play_pause|media_prev|media_stop|numlock|numpad0|numpad1|numpad2|numpad3|numpad4|numpad5|numpad6|numpad7|numpad8|numpad9|numpadadd|numpadclear|numpaddel|numpaddiv|numpaddot|numpaddown|numpadend|numpadenter|numpadhome|numpadins|numpadleft|numpadmult|numpadpgdn|numpadpgup|numpadright|numpadsub|numpadup|pgdn|pgup|printscreen|ralt|rbutton|rcontrol|rctrl|right|rshift|rwin|rwindown|rwinup|scrolllock|shift|shiftdown|shiftup|space|tab|up|volume_down|volume_mute|volume_up|wheeldown|wheelleft|wheelright|wheelup|xbutton1|xbutton2)\b/i,important:/#\b(?:AllowSameLineComments|ClipboardTimeout|CommentFlag|DerefChar|ErrorStdOut|EscapeChar|HotkeyInterval|HotkeyModifierTimeout|Hotstring|If|IfTimeout|IfWinActive|IfWinExist|IfWinNotActive|IfWinNotExist|Include|IncludeAgain|InputLevel|InstallKeybdHook|InstallMouseHook|KeyHistory|MaxHotkeysPerInterval|MaxMem|MaxThreads|MaxThreadsBuffer|MaxThreadsPerHotkey|MenuMaskKey|NoEnv|NoTrayIcon|Persistent|SingleInstance|UseHook|Warn|WinActivateForce)\b/i,keyword:/\b(?:Abort|AboveNormal|Add|ahk_class|ahk_exe|ahk_group|ahk_id|ahk_pid|All|Alnum|Alpha|AltSubmit|AltTab|AltTabAndMenu|AltTabMenu|AltTabMenuDismiss|AlwaysOnTop|AutoSize|Background|BackgroundTrans|BelowNormal|between|BitAnd|BitNot|BitOr|BitShiftLeft|BitShiftRight|BitXOr|Bold|Border|Button|ByRef|Catch|Checkbox|Checked|CheckedGray|Choose|ChooseString|Close|Color|ComboBox|Contains|ControlList|Count|Date|DateTime|Days|DDL|Default|DeleteAll|Delimiter|Deref|Destroy|Digit|Disable|Disabled|DropDownList|Edit|Eject|Else|Enable|Enabled|Error|Exist|Expand|ExStyle|FileSystem|Finally|First|Flash|Float|FloatFast|Focus|Font|for|global|Grid|Group|GroupBox|GuiClose|GuiContextMenu|GuiDropFiles|GuiEscape|GuiSize|Hdr|Hidden|Hide|High|HKCC|HKCR|HKCU|HKEY_CLASSES_ROOT|HKEY_CURRENT_CONFIG|HKEY_CURRENT_USER|HKEY_LOCAL_MACHINE|HKEY_USERS|HKLM|HKU|Hours|HScroll|Icon|IconSmall|ID|IDLast|If|IfEqual|IfExist|IfGreater|IfGreaterOrEqual|IfInString|IfLess|IfLessOrEqual|IfMsgBox|IfNotEqual|IfNotExist|IfNotInString|IfWinActive|IfWinExist|IfWinNotActive|IfWinNotExist|Ignore|ImageList|in|Integer|IntegerFast|Interrupt|is|italic|Join|Label|LastFound|LastFoundExist|Limit|Lines|List|ListBox|ListView|local|Lock|Logoff|Low|Lower|Lowercase|MainWindow|Margin|Maximize|MaximizeBox|MaxSize|Minimize|MinimizeBox|MinMax|MinSize|Minutes|MonthCal|Mouse|Move|Multi|NA|No|NoActivate|NoDefault|NoHide|NoIcon|NoMainWindow|norm|Normal|NoSort|NoSortHdr|NoStandard|Not|NoTab|NoTimers|Number|Off|Ok|On|OwnDialogs|Owner|Parse|Password|Picture|Pixel|Pos|Pow|Priority|ProcessName|Radio|Range|Read|ReadOnly|Realtime|Redraw|Region|REG_BINARY|REG_DWORD|REG_EXPAND_SZ|REG_MULTI_SZ|REG_SZ|Relative|Rename|Report|Resize|Restore|Retry|RGB|Screen|Seconds|Section|Serial|SetLabel|ShiftAltTab|Show|Single|Slider|SortDesc|Standard|static|Status|StatusBar|StatusCD|strike|Style|Submit|SysMenu|Tab2|TabStop|Text|Theme|Throw|Tile|ToggleCheck|ToggleEnable|ToolWindow|Top|Topmost|TransColor|Transparent|Tray|TreeView|Try|TryAgain|Type|UnCheck|underline|Unicode|Unlock|Until|UpDown|Upper|Uppercase|UseErrorLevel|Vis|VisFirst|Visible|VScroll|Wait|WaitClose|WantCtrlA|WantF2|WantReturn|While|Wrap|Xdigit|xm|xp|xs|Yes|ym|yp|ys)\b/i,function:/[^(); \t,\n+*\-=?>:\\\/<&%\[\]]+(?=\()/,punctuation:/[{}[\]():,]/}}e.exports=t,t.displayName="autohotkey",t.aliases=[]},51400:(e,t,o)=>{o.d(t,{default:()=>i});var a=o(23549);const i=o.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/51414.1b5a0681.chunk.js b/ydb/core/viewer/monitoring/static/js/51414.1b5a0681.chunk.js new file mode 100644 index 000000000000..02e86e85228e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51414.1b5a0681.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 51414.1b5a0681.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51414],{51414:(e,t,r)=>{r.r(t),r.d(t,{conf:()=>s,language:()=>n});var s={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#%\^\&\*\(\)\=\$\-\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{blockComment:["###","###"],lineComment:"#"},folding:{markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},n={defaultToken:"",ignoreCase:!1,tokenPostfix:".mips",regEx:/\/(?!\/\/)(?:[^\/\\]|\\.)*\/[igm]*/,keywords:[".data",".text","syscall","trap","add","addu","addi","addiu","and","andi","div","divu","mult","multu","nor","or","ori","sll","slv","sra","srav","srl","srlv","sub","subu","xor","xori","lhi","lho","lhi","llo","slt","slti","sltu","sltiu","beq","bgtz","blez","bne","j","jal","jalr","jr","lb","lbu","lh","lhu","lw","li","la","sb","sh","sw","mfhi","mflo","mthi","mtlo","move"],symbols:/[\.,\:]+/,escapes:/\\(?:[abfnrtv\\"'$]|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[[/\$[a-zA-Z_]\w*/,"variable.predefined"],[/[.a-zA-Z_]\w*/,{cases:{this:"variable.predefined","@keywords":{token:"keyword.$0"},"@default":""}}],[/[ \t\r\n]+/,""],[/#.*$/,"comment"],["///",{token:"regexp",next:"@hereregexp"}],[/^(\s*)(@regEx)/,["","regexp"]],[/(\,)(\s*)(@regEx)/,["delimiter","","regexp"]],[/(\:)(\s*)(@regEx)/,["delimiter","","regexp"]],[/@symbols/,"delimiter"],[/\d+[eE]([\-+]?\d+)?/,"number.float"],[/\d+\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/0[0-7]+(?!\d)/,"number.octal"],[/\d+/,"number"],[/[,.]/,"delimiter"],[/"""/,"string",'@herestring."""'],[/'''/,"string","@herestring.'''"],[/"/,{cases:{"@eos":"string","@default":{token:"string",next:'@string."'}}}],[/'/,{cases:{"@eos":"string","@default":{token:"string",next:"@string.'"}}}]],string:[[/[^"'\#\\]+/,"string"],[/@escapes/,"string.escape"],[/\./,"string.escape.invalid"],[/\./,"string.escape.invalid"],[/#{/,{cases:{'$S2=="':{token:"string",next:"root.interpolatedstring"},"@default":"string"}}],[/["']/,{cases:{"$#==$S2":{token:"string",next:"@pop"},"@default":"string"}}],[/#/,"string"]],herestring:[[/("""|''')/,{cases:{"$1==$S2":{token:"string",next:"@pop"},"@default":"string"}}],[/[^#\\'"]+/,"string"],[/['"]+/,"string"],[/@escapes/,"string.escape"],[/\./,"string.escape.invalid"],[/#{/,{token:"string.quote",next:"root.interpolatedstring"}],[/#/,"string"]],comment:[[/[^#]+/,"comment"],[/#/,"comment"]],hereregexp:[[/[^\\\/#]+/,"regexp"],[/\\./,"regexp"],[/#.*$/,"comment"],["///[igm]*",{token:"regexp",next:"@pop"}],[/\//,"regexp"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5252.991dcab8.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/51414.1b5a0681.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5252.991dcab8.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/51414.1b5a0681.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/51496.423aebfa.chunk.js b/ydb/core/viewer/monitoring/static/js/51496.423aebfa.chunk.js new file mode 100644 index 000000000000..e392a119a6a4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51496.423aebfa.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51496],{51496:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"en-in",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},ordinal:function(e){var a=["th","st","nd","rd"],_=e%100;return"["+e+(a[(_-20)%10]||a[_]||a[0])+"]"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5161.20e37d15.chunk.js b/ydb/core/viewer/monitoring/static/js/5161.20e37d15.chunk.js deleted file mode 100644 index 46cd2559aab0..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5161.20e37d15.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5161],{35161:function(e,a,d){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var d=a(e),_={name:"nl-be",weekdays:"zondag_maandag_dinsdag_woensdag_donderdag_vrijdag_zaterdag".split("_"),months:"januari_februari_maart_april_mei_juni_juli_augustus_september_oktober_november_december".split("_"),monthsShort:"jan._feb._mrt._apr._mei_jun._jul._aug._sep._okt._nov._dec.".split("_"),weekStart:1,weekdaysShort:"zo._ma._di._wo._do._vr._za.".split("_"),weekdaysMin:"zo_ma_di_wo_do_vr_za".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"over %s",past:"%s geleden",s:"een paar seconden",m:"\xe9\xe9n minuut",mm:"%d minuten",h:"\xe9\xe9n uur",hh:"%d uur",d:"\xe9\xe9n dag",dd:"%d dagen",M:"\xe9\xe9n maand",MM:"%d maanden",y:"\xe9\xe9n jaar",yy:"%d jaar"}};return d.default.locale(_,null,!0),_}(d(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/51627.9762f671.chunk.js b/ydb/core/viewer/monitoring/static/js/51627.9762f671.chunk.js new file mode 100644 index 000000000000..a9933242af7f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/51627.9762f671.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[51627],{51627:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),t={name:"en-nz",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){var _=["th","st","nd","rd"],a=e%100;return"["+e+(_[(a-20)%10]||_[a]||_[0])+"]"},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(t,null,!0),t}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/52036.0bcd45d5.chunk.js b/ydb/core/viewer/monitoring/static/js/52036.0bcd45d5.chunk.js new file mode 100644 index 000000000000..aef6c2058558 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/52036.0bcd45d5.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[52036],{3899:a=>{function e(a){!function(a){var e=a.languages.javadoclike={parameter:{pattern:/(^[\t ]*(?:\/{3}|\*|\/\*\*)\s*@(?:arg|arguments|param)\s+)\w+/m,lookbehind:!0},keyword:{pattern:/(^[\t ]*(?:\/{3}|\*|\/\*\*)\s*|\{)@[a-z][a-zA-Z-]+\b/m,lookbehind:!0},punctuation:/[{}]/};Object.defineProperty(e,"addSupport",{value:function(e,n){"string"===typeof e&&(e=[e]),e.forEach((function(e){!function(e,n){var t="doc-comment",i=a.languages[e];if(i){var r=i[t];if(!r){var o={};o[t]={pattern:/(^|[^\\])\/\*\*[^/][\s\S]*?(?:\*\/|$)/,lookbehind:!0,alias:"comment"},r=(i=a.languages.insertBefore(e,"comment",o))[t]}if(r instanceof RegExp&&(r=i[t]={pattern:r}),Array.isArray(r))for(var s=0,d=r.length;s{n.d(e,{default:()=>i});var t=n(3899);const i=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/52182.735ff091.chunk.js b/ydb/core/viewer/monitoring/static/js/52182.735ff091.chunk.js new file mode 100644 index 000000000000..3db903bf7e52 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/52182.735ff091.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[52182],{52182:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e);function r(e){return e%100==2}function a(e){return e%100==3||e%100==4}function m(e,n,t,m){var u=e+" ";switch(t){case"s":return n||m?"nekaj sekund":"nekaj sekundami";case"m":return n?"ena minuta":"eno minuto";case"mm":return r(e)?u+(n||m?"minuti":"minutama"):a(e)?u+(n||m?"minute":"minutami"):u+(n||m?"minut":"minutami");case"h":return n?"ena ura":"eno uro";case"hh":return r(e)?u+(n||m?"uri":"urama"):a(e)?u+(n||m?"ure":"urami"):u+(n||m?"ur":"urami");case"d":return n||m?"en dan":"enim dnem";case"dd":return r(e)?u+(n||m?"dneva":"dnevoma"):u+(n||m?"dni":"dnevi");case"M":return n||m?"en mesec":"enim mesecem";case"MM":return r(e)?u+(n||m?"meseca":"mesecema"):a(e)?u+(n||m?"mesece":"meseci"):u+(n||m?"mesecev":"meseci");case"y":return n||m?"eno leto":"enim letom";case"yy":return r(e)?u+(n||m?"leti":"letoma"):a(e)?u+(n||m?"leta":"leti"):u+(n||m?"let":"leti")}}var u={name:"sl",weekdays:"nedelja_ponedeljek_torek_sreda_\u010detrtek_petek_sobota".split("_"),months:"januar_februar_marec_april_maj_junij_julij_avgust_september_oktober_november_december".split("_"),weekStart:1,weekdaysShort:"ned._pon._tor._sre._\u010det._pet._sob.".split("_"),monthsShort:"jan._feb._mar._apr._maj._jun._jul._avg._sep._okt._nov._dec.".split("_"),weekdaysMin:"ne_po_to_sr_\u010de_pe_so".split("_"),ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm",l:"D. M. YYYY"},relativeTime:{future:"\u010dez %s",past:"pred %s",s:m,m:m,mm:m,h:m,hh:m,d:m,dd:m,M:m,MM:m,y:m,yy:m}};return t.default.locale(u,null,!0),u}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/523.17013d4e.chunk.js b/ydb/core/viewer/monitoring/static/js/523.17013d4e.chunk.js deleted file mode 100644 index 00e9a25fa4b1..000000000000 --- a/ydb/core/viewer/monitoring/static/js/523.17013d4e.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[523],{30523:function(e,_,s){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var s=_(e),o={name:"es-do",weekdays:"domingo_lunes_martes_mi\xe9rcoles_jueves_viernes_s\xe1bado".split("_"),weekdaysShort:"dom._lun._mar._mi\xe9._jue._vie._s\xe1b.".split("_"),weekdaysMin:"do_lu_ma_mi_ju_vi_s\xe1".split("_"),months:"enero_febrero_marzo_abril_mayo_junio_julio_agosto_septiembre_octubre_noviembre_diciembre".split("_"),monthsShort:"ene_feb_mar_abr_may_jun_jul_ago_sep_oct_nov_dic".split("_"),weekStart:1,relativeTime:{future:"en %s",past:"hace %s",s:"unos segundos",m:"un minuto",mm:"%d minutos",h:"una hora",hh:"%d horas",d:"un d\xeda",dd:"%d d\xedas",M:"un mes",MM:"%d meses",y:"un a\xf1o",yy:"%d a\xf1os"},ordinal:function(e){return e+"\xba"},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY h:mm A",LLLL:"dddd, D [de] MMMM [de] YYYY h:mm A"}};return s.default.locale(o,null,!0),o}(s(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/52518.2a3ff21a.chunk.js b/ydb/core/viewer/monitoring/static/js/52518.2a3ff21a.chunk.js new file mode 100644 index 000000000000..feb4e1d8275c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/52518.2a3ff21a.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 52518.2a3ff21a.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[52518],{52518:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>s,language:()=>o});var s={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\$\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"},{open:'"',close:'"'}],folding:{markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},o={defaultToken:"",tokenPostfix:".cs",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["extern","alias","using","bool","decimal","sbyte","byte","short","ushort","int","uint","long","ulong","char","float","double","object","dynamic","string","assembly","is","as","ref","out","this","base","new","typeof","void","checked","unchecked","default","delegate","var","const","if","else","switch","case","while","do","for","foreach","in","break","continue","goto","return","throw","try","catch","finally","lock","yield","from","let","where","join","on","equals","into","orderby","ascending","descending","select","group","by","namespace","partial","class","field","event","method","param","public","protected","internal","private","abstract","sealed","static","struct","readonly","volatile","virtual","override","params","get","set","add","remove","operator","true","false","implicit","explicit","interface","enum","null","async","await","fixed","sizeof","stackalloc","unsafe","nameof","when"],namespaceFollows:["namespace","using"],parenFollows:["if","for","while","switch","foreach","using","catch","when"],operators:["=","??","||","&&","|","^","&","==","!=","<=",">=","<<","+","-","*","/","%","!","~","++","--","+=","-=","*=","/=","%=","&=","|=","^=","<<=",">>=",">>","=>"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/[0-9_]*\.[0-9_]+([eE][\-+]?\d+)?[fFdD]?/,"number.float"],[/0[xX][0-9a-fA-F_]+/,"number.hex"],[/0[bB][01_]+/,"number.hex"],[/[0-9_]+/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,{token:"string.quote",next:"@string"}],[/\$\@"/,{token:"string.quote",next:"@litinterpstring"}],[/\@"/,{token:"string.quote",next:"@litstring"}],[/\$"/,{token:"string.quote",next:"@interpolatedstring"}],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],qualified:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],[/\./,"delimiter"],["","","@pop"]],namespace:[{include:"@whitespace"},[/[A-Z]\w*/,"namespace"],[/[\.=]/,"delimiter"],["","","@pop"]],comment:[[/[^\/*]+/,"comment"],["\\*/","comment","@pop"],[/[\/*]/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",next:"@pop"}]],litstring:[[/[^"]+/,"string"],[/""/,"string.escape"],[/"/,{token:"string.quote",next:"@pop"}]],litinterpstring:[[/[^"{]+/,"string"],[/""/,"string.escape"],[/{{/,"string.escape"],[/}}/,"string.escape"],[/{/,{token:"string.quote",next:"root.litinterpstring"}],[/"/,{token:"string.quote",next:"@pop"}]],interpolatedstring:[[/[^\\"{]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/{{/,"string.escape"],[/}}/,"string.escape"],[/{/,{token:"string.quote",next:"root.interpolatedstring"}],[/"/,{token:"string.quote",next:"@pop"}]],whitespace:[[/^[ \t\v\f]*#((r)|(load))(?=\s)/,"directive.csx"],[/^[ \t\v\f]*#\w.*$/,"namespace.cpp"],[/[ \t\v\f\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5382.3a2e6ac6.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/52518.2a3ff21a.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5382.3a2e6ac6.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/52518.2a3ff21a.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/5252.991dcab8.chunk.js b/ydb/core/viewer/monitoring/static/js/5252.991dcab8.chunk.js deleted file mode 100644 index 2d9d1f59d845..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5252.991dcab8.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5252.991dcab8.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5252],{65252:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>h,language:()=>b});var a,r,m=n(80781),l=Object.defineProperty,i=Object.getOwnPropertyDescriptor,o=Object.getOwnPropertyNames,d=Object.prototype.hasOwnProperty,s=(e,t,n,a)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let r of o(t))d.call(e,r)||r===n||l(e,r,{get:()=>t[r],enumerable:!(a=i(t,r))||a.enumerable});return e},c={};s(c,a=m,"default"),r&&s(r,a,"default");var p=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],h={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,comments:{blockComment:["{{!--","--}}"]},brackets:[["\x3c!--","--\x3e"],["<",">"],["{{","}}"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/(\w[\w\d]*)\s*>$/i,action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:c.languages.IndentAction.Indent}}]},b={defaultToken:"",tokenPostfix:"",tokenizer:{root:[[/\{\{!--/,"comment.block.start.handlebars","@commentBlock"],[/\{\{!/,"comment.start.handlebars","@comment"],[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.root"}],[/)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)(script)/,["delimiter.html",{token:"tag.html",next:"@script"}]],[/(<)(style)/,["delimiter.html",{token:"tag.html",next:"@style"}]],[/(<)([:\w]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)(\w+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/]+/,"metatag.content.html"],[/>/,"metatag.html","@pop"]],comment:[[/\}\}/,"comment.end.handlebars","@pop"],[/./,"comment.content.handlebars"]],commentBlock:[[/--\}\}/,"comment.block.end.handlebars","@pop"],[/./,"comment.content.handlebars"]],commentHtml:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.comment"}],[/-->/,"comment.html","@pop"],[/[^-]+/,"comment.content.html"],[/./,"comment.content.html"]],otherTag:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.otherTag"}],[/\/?>/,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.script"}],[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],scriptAfterType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.scriptAfterType"}],[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.scriptAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.scriptWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInEmbeddedState.scriptEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],style:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.style"}],[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],styleAfterType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.styleAfterType"}],[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.styleAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.styleWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInEmbeddedState.styleEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],handlebarsInSimpleState:[[/\{\{\{?/,"delimiter.handlebars"],[/\}\}\}?/,{token:"delimiter.handlebars",switchTo:"@$S2.$S3"}],{include:"handlebarsRoot"}],handlebarsInEmbeddedState:[[/\{\{\{?/,"delimiter.handlebars"],[/\}\}\}?/,{token:"delimiter.handlebars",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}],{include:"handlebarsRoot"}],handlebarsRoot:[[/"[^"]*"/,"string.handlebars"],[/[#/][^\s}]+/,"keyword.helper.handlebars"],[/else\b/,"keyword.helper.handlebars"],[/[\s]+/],[/[^}]/,"variable.parameter.handlebars"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/52527.57100447.chunk.js b/ydb/core/viewer/monitoring/static/js/52527.57100447.chunk.js new file mode 100644 index 000000000000..2ac62272e49d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/52527.57100447.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[52527],{24376:e=>{function a(e){!function(e){function a(a,n){e.languages[a]&&e.languages.insertBefore(a,"comment",{"doc-comment":n})}var n=e.languages.markup.tag,t={pattern:/\/\/\/.*/,greedy:!0,alias:"comment",inside:{tag:n}},s={pattern:/'''.*/,greedy:!0,alias:"comment",inside:{tag:n}};a("csharp",t),a("fsharp",t),a("vbnet",s)}(e)}e.exports=a,a.displayName="xmlDoc",a.aliases=[]},52527:(e,a,n)=>{n.d(a,{default:()=>s});var t=n(24376);const s=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5254.ef9c1c59.chunk.js b/ydb/core/viewer/monitoring/static/js/5254.ef9c1c59.chunk.js new file mode 100644 index 000000000000..bb2c71835c12 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/5254.ef9c1c59.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5254],{5254:(e,a,n)=>{n.d(a,{default:()=>t});var i=n(65165);const t=n.n(i)()},65165:e=>{function a(e){e.languages.dhall={comment:/--.*|\{-(?:[^-{]|-(?!\})|\{(?!-)|\{-(?:[^-{]|-(?!\})|\{(?!-))*-\})*-\}/,string:{pattern:/"(?:[^"\\]|\\.)*"|''(?:[^']|'(?!')|'''|''\$\{)*''(?!'|\$)/,greedy:!0,inside:{interpolation:{pattern:/\$\{[^{}]*\}/,inside:{expression:{pattern:/(^\$\{)[\s\S]+(?=\}$)/,lookbehind:!0,alias:"language-dhall",inside:null},punctuation:/\$\{|\}/}}}},label:{pattern:/`[^`]*`/,greedy:!0},url:{pattern:/\bhttps?:\/\/[\w.:%!$&'*+;=@~-]+(?:\/[\w.:%!$&'*+;=@~-]*)*(?:\?[/?\w.:%!$&'*+;=@~-]*)?/,greedy:!0},env:{pattern:/\benv:(?:(?!\d)\w+|"(?:[^"\\=]|\\.)*")/,greedy:!0,inside:{function:/^env/,operator:/^:/,variable:/[\s\S]+/}},hash:{pattern:/\bsha256:[\da-fA-F]{64}\b/,inside:{function:/sha256/,operator:/:/,number:/[\da-fA-F]{64}/}},keyword:/\b(?:as|assert|else|forall|if|in|let|merge|missing|then|toMap|using|with)\b|\u2200/,builtin:/\b(?:None|Some)\b/,boolean:/\b(?:False|True)\b/,number:/\bNaN\b|-?\bInfinity\b|[+-]?\b(?:0x[\da-fA-F]+|\d+(?:\.\d+)?(?:e[+-]?\d+)?)\b/,operator:/\/\\|\/\/\\\\|&&|\|\||===|[!=]=|\/\/|->|\+\+|::|[+*#@=:?<>|\\\u2227\u2a53\u2261\u2afd\u03bb\u2192]/,punctuation:/\.\.|[{}\[\](),./]/,"class-name":/\b[A-Z]\w*\b/},e.languages.dhall.string.inside.interpolation.inside.expression.inside=e.languages.dhall}e.exports=a,a.displayName="dhall",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/52541.7c3f886c.chunk.js b/ydb/core/viewer/monitoring/static/js/52541.7c3f886c.chunk.js new file mode 100644 index 000000000000..c87ec3e45293 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/52541.7c3f886c.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[52541],{52541:(E,T,I)=>{I.d(T,{default:()=>R});var A=I(55890);const R=I.n(A)()},55890:(E,T,I)=>{var A=I(70502);function R(E){E.register(A),E.languages.plsql=E.languages.extend("sql",{comment:{pattern:/\/\*[\s\S]*?\*\/|--.*/,greedy:!0},keyword:/\b(?:A|ACCESSIBLE|ADD|AGENT|AGGREGATE|ALL|ALTER|AND|ANY|ARRAY|AS|ASC|AT|ATTRIBUTE|AUTHID|AVG|BEGIN|BETWEEN|BFILE_BASE|BINARY|BLOB_BASE|BLOCK|BODY|BOTH|BOUND|BULK|BY|BYTE|C|CALL|CALLING|CASCADE|CASE|CHAR|CHARACTER|CHARSET|CHARSETFORM|CHARSETID|CHAR_BASE|CHECK|CLOB_BASE|CLONE|CLOSE|CLUSTER|CLUSTERS|COLAUTH|COLLECT|COLUMNS|COMMENT|COMMIT|COMMITTED|COMPILED|COMPRESS|CONNECT|CONSTANT|CONSTRUCTOR|CONTEXT|CONTINUE|CONVERT|COUNT|CRASH|CREATE|CREDENTIAL|CURRENT|CURSOR|CUSTOMDATUM|DANGLING|DATA|DATE|DATE_BASE|DAY|DECLARE|DEFAULT|DEFINE|DELETE|DESC|DETERMINISTIC|DIRECTORY|DISTINCT|DOUBLE|DROP|DURATION|ELEMENT|ELSE|ELSIF|EMPTY|END|ESCAPE|EXCEPT|EXCEPTION|EXCEPTIONS|EXCLUSIVE|EXECUTE|EXISTS|EXIT|EXTERNAL|FETCH|FINAL|FIRST|FIXED|FLOAT|FOR|FORALL|FORCE|FROM|FUNCTION|GENERAL|GOTO|GRANT|GROUP|HASH|HAVING|HEAP|HIDDEN|HOUR|IDENTIFIED|IF|IMMEDIATE|IMMUTABLE|IN|INCLUDING|INDEX|INDEXES|INDICATOR|INDICES|INFINITE|INSERT|INSTANTIABLE|INT|INTERFACE|INTERSECT|INTERVAL|INTO|INVALIDATE|IS|ISOLATION|JAVA|LANGUAGE|LARGE|LEADING|LENGTH|LEVEL|LIBRARY|LIKE|LIKE2|LIKE4|LIKEC|LIMIT|LIMITED|LOCAL|LOCK|LONG|LOOP|MAP|MAX|MAXLEN|MEMBER|MERGE|MIN|MINUS|MINUTE|MOD|MODE|MODIFY|MONTH|MULTISET|MUTABLE|NAME|NAN|NATIONAL|NATIVE|NCHAR|NEW|NOCOMPRESS|NOCOPY|NOT|NOWAIT|NULL|NUMBER_BASE|OBJECT|OCICOLL|OCIDATE|OCIDATETIME|OCIDURATION|OCIINTERVAL|OCILOBLOCATOR|OCINUMBER|OCIRAW|OCIREF|OCIREFCURSOR|OCIROWID|OCISTRING|OCITYPE|OF|OLD|ON|ONLY|OPAQUE|OPEN|OPERATOR|OPTION|OR|ORACLE|ORADATA|ORDER|ORGANIZATION|ORLANY|ORLVARY|OTHERS|OUT|OVERLAPS|OVERRIDING|PACKAGE|PARALLEL_ENABLE|PARAMETER|PARAMETERS|PARENT|PARTITION|PASCAL|PERSISTABLE|PIPE|PIPELINED|PLUGGABLE|POLYMORPHIC|PRAGMA|PRECISION|PRIOR|PRIVATE|PROCEDURE|PUBLIC|RAISE|RANGE|RAW|READ|RECORD|REF|REFERENCE|RELIES_ON|REM|REMAINDER|RENAME|RESOURCE|RESULT|RESULT_CACHE|RETURN|RETURNING|REVERSE|REVOKE|ROLLBACK|ROW|SAMPLE|SAVE|SAVEPOINT|SB1|SB2|SB4|SECOND|SEGMENT|SELECT|SELF|SEPARATE|SEQUENCE|SERIALIZABLE|SET|SHARE|SHORT|SIZE|SIZE_T|SOME|SPARSE|SQL|SQLCODE|SQLDATA|SQLNAME|SQLSTATE|STANDARD|START|STATIC|STDDEV|STORED|STRING|STRUCT|STYLE|SUBMULTISET|SUBPARTITION|SUBSTITUTABLE|SUBTYPE|SUM|SYNONYM|TABAUTH|TABLE|TDO|THE|THEN|TIME|TIMESTAMP|TIMEZONE_ABBR|TIMEZONE_HOUR|TIMEZONE_MINUTE|TIMEZONE_REGION|TO|TRAILING|TRANSACTION|TRANSACTIONAL|TRUSTED|TYPE|UB1|UB2|UB4|UNDER|UNION|UNIQUE|UNPLUG|UNSIGNED|UNTRUSTED|UPDATE|USE|USING|VALIST|VALUE|VALUES|VARIABLE|VARIANCE|VARRAY|VARYING|VIEW|VIEWS|VOID|WHEN|WHERE|WHILE|WITH|WORK|WRAPPED|WRITE|YEAR|ZONE)\b/i,operator:/:=?|=>|[<>^~!]=|\.\.|\|\||\*\*|[-+*/%<>=@]/}),E.languages.insertBefore("plsql","operator",{label:{pattern:/<<\s*\w+\s*>>/,alias:"symbol"}})}E.exports=R,R.displayName="plsql",R.aliases=[]},70502:E=>{function T(E){E.languages.sql={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|(?:--|\/\/|#).*)/,lookbehind:!0},variable:[{pattern:/@(["'`])(?:\\[\s\S]|(?!\1)[^\\])+\1/,greedy:!0},/@[\w.$]+/],string:{pattern:/(^|[^@\\])("|')(?:\\[\s\S]|(?!\2)[^\\]|\2\2)*\2/,greedy:!0,lookbehind:!0},identifier:{pattern:/(^|[^@\\])`(?:\\[\s\S]|[^`\\]|``)*`/,greedy:!0,lookbehind:!0,inside:{punctuation:/^`|`$/}},function:/\b(?:AVG|COUNT|FIRST|FORMAT|LAST|LCASE|LEN|MAX|MID|MIN|MOD|NOW|ROUND|SUM|UCASE)(?=\s*\()/i,keyword:/\b(?:ACTION|ADD|AFTER|ALGORITHM|ALL|ALTER|ANALYZE|ANY|APPLY|AS|ASC|AUTHORIZATION|AUTO_INCREMENT|BACKUP|BDB|BEGIN|BERKELEYDB|BIGINT|BINARY|BIT|BLOB|BOOL|BOOLEAN|BREAK|BROWSE|BTREE|BULK|BY|CALL|CASCADED?|CASE|CHAIN|CHAR(?:ACTER|SET)?|CHECK(?:POINT)?|CLOSE|CLUSTERED|COALESCE|COLLATE|COLUMNS?|COMMENT|COMMIT(?:TED)?|COMPUTE|CONNECT|CONSISTENT|CONSTRAINT|CONTAINS(?:TABLE)?|CONTINUE|CONVERT|CREATE|CROSS|CURRENT(?:_DATE|_TIME|_TIMESTAMP|_USER)?|CURSOR|CYCLE|DATA(?:BASES?)?|DATE(?:TIME)?|DAY|DBCC|DEALLOCATE|DEC|DECIMAL|DECLARE|DEFAULT|DEFINER|DELAYED|DELETE|DELIMITERS?|DENY|DESC|DESCRIBE|DETERMINISTIC|DISABLE|DISCARD|DISK|DISTINCT|DISTINCTROW|DISTRIBUTED|DO|DOUBLE|DROP|DUMMY|DUMP(?:FILE)?|DUPLICATE|ELSE(?:IF)?|ENABLE|ENCLOSED|END|ENGINE|ENUM|ERRLVL|ERRORS|ESCAPED?|EXCEPT|EXEC(?:UTE)?|EXISTS|EXIT|EXPLAIN|EXTENDED|FETCH|FIELDS|FILE|FILLFACTOR|FIRST|FIXED|FLOAT|FOLLOWING|FOR(?: EACH ROW)?|FORCE|FOREIGN|FREETEXT(?:TABLE)?|FROM|FULL|FUNCTION|GEOMETRY(?:COLLECTION)?|GLOBAL|GOTO|GRANT|GROUP|HANDLER|HASH|HAVING|HOLDLOCK|HOUR|IDENTITY(?:COL|_INSERT)?|IF|IGNORE|IMPORT|INDEX|INFILE|INNER|INNODB|INOUT|INSERT|INT|INTEGER|INTERSECT|INTERVAL|INTO|INVOKER|ISOLATION|ITERATE|JOIN|KEYS?|KILL|LANGUAGE|LAST|LEAVE|LEFT|LEVEL|LIMIT|LINENO|LINES|LINESTRING|LOAD|LOCAL|LOCK|LONG(?:BLOB|TEXT)|LOOP|MATCH(?:ED)?|MEDIUM(?:BLOB|INT|TEXT)|MERGE|MIDDLEINT|MINUTE|MODE|MODIFIES|MODIFY|MONTH|MULTI(?:LINESTRING|POINT|POLYGON)|NATIONAL|NATURAL|NCHAR|NEXT|NO|NONCLUSTERED|NULLIF|NUMERIC|OFF?|OFFSETS?|ON|OPEN(?:DATASOURCE|QUERY|ROWSET)?|OPTIMIZE|OPTION(?:ALLY)?|ORDER|OUT(?:ER|FILE)?|OVER|PARTIAL|PARTITION|PERCENT|PIVOT|PLAN|POINT|POLYGON|PRECEDING|PRECISION|PREPARE|PREV|PRIMARY|PRINT|PRIVILEGES|PROC(?:EDURE)?|PUBLIC|PURGE|QUICK|RAISERROR|READS?|REAL|RECONFIGURE|REFERENCES|RELEASE|RENAME|REPEAT(?:ABLE)?|REPLACE|REPLICATION|REQUIRE|RESIGNAL|RESTORE|RESTRICT|RETURN(?:ING|S)?|REVOKE|RIGHT|ROLLBACK|ROUTINE|ROW(?:COUNT|GUIDCOL|S)?|RTREE|RULE|SAVE(?:POINT)?|SCHEMA|SECOND|SELECT|SERIAL(?:IZABLE)?|SESSION(?:_USER)?|SET(?:USER)?|SHARE|SHOW|SHUTDOWN|SIMPLE|SMALLINT|SNAPSHOT|SOME|SONAME|SQL|START(?:ING)?|STATISTICS|STATUS|STRIPED|SYSTEM_USER|TABLES?|TABLESPACE|TEMP(?:ORARY|TABLE)?|TERMINATED|TEXT(?:SIZE)?|THEN|TIME(?:STAMP)?|TINY(?:BLOB|INT|TEXT)|TOP?|TRAN(?:SACTIONS?)?|TRIGGER|TRUNCATE|TSEQUAL|TYPES?|UNBOUNDED|UNCOMMITTED|UNDEFINED|UNION|UNIQUE|UNLOCK|UNPIVOT|UNSIGNED|UPDATE(?:TEXT)?|USAGE|USE|USER|USING|VALUES?|VAR(?:BINARY|CHAR|CHARACTER|YING)|VIEW|WAITFOR|WARNINGS|WHEN|WHERE|WHILE|WITH(?: ROLLUP|IN)?|WORK|WRITE(?:TEXT)?|YEAR)\b/i,boolean:/\b(?:FALSE|NULL|TRUE)\b/i,number:/\b0x[\da-f]+\b|\b\d+(?:\.\d*)?|\B\.\d+\b/i,operator:/[-+*\/=%^~]|&&?|\|\|?|!=?|<(?:=>?|<|>)?|>[>=]?|\b(?:AND|BETWEEN|DIV|ILIKE|IN|IS|LIKE|NOT|OR|REGEXP|RLIKE|SOUNDS LIKE|XOR)\b/i,punctuation:/[;[\]()`,.]/}}E.exports=T,T.displayName="sql",T.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5282.37c7be51.chunk.js b/ydb/core/viewer/monitoring/static/js/5282.37c7be51.chunk.js new file mode 100644 index 000000000000..1235a841f570 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/5282.37c7be51.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5282],{5282:(E,T,R)=>{R.d(T,{default:()=>I});var N=R(37253);const I=R.n(N)()},7208:E=>{function T(E){E.languages.basic={comment:{pattern:/(?:!|REM\b).+/i,inside:{keyword:/^REM/i}},string:{pattern:/"(?:""|[!#$%&'()*,\/:;<=>?^\w +\-.])*"/,greedy:!0},number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:E[+-]?\d+)?/i,keyword:/\b(?:AS|BEEP|BLOAD|BSAVE|CALL(?: ABSOLUTE)?|CASE|CHAIN|CHDIR|CLEAR|CLOSE|CLS|COM|COMMON|CONST|DATA|DECLARE|DEF(?: FN| SEG|DBL|INT|LNG|SNG|STR)|DIM|DO|DOUBLE|ELSE|ELSEIF|END|ENVIRON|ERASE|ERROR|EXIT|FIELD|FILES|FOR|FUNCTION|GET|GOSUB|GOTO|IF|INPUT|INTEGER|IOCTL|KEY|KILL|LINE INPUT|LOCATE|LOCK|LONG|LOOP|LSET|MKDIR|NAME|NEXT|OFF|ON(?: COM| ERROR| KEY| TIMER)?|OPEN|OPTION BASE|OUT|POKE|PUT|READ|REDIM|REM|RESTORE|RESUME|RETURN|RMDIR|RSET|RUN|SELECT CASE|SHARED|SHELL|SINGLE|SLEEP|STATIC|STEP|STOP|STRING|SUB|SWAP|SYSTEM|THEN|TIMER|TO|TROFF|TRON|TYPE|UNLOCK|UNTIL|USING|VIEW PRINT|WAIT|WEND|WHILE|WRITE)(?:\$|\b)/i,function:/\b(?:ABS|ACCESS|ACOS|ANGLE|AREA|ARITHMETIC|ARRAY|ASIN|ASK|AT|ATN|BASE|BEGIN|BREAK|CAUSE|CEIL|CHR|CLIP|COLLATE|COLOR|CON|COS|COSH|COT|CSC|DATE|DATUM|DEBUG|DECIMAL|DEF|DEG|DEGREES|DELETE|DET|DEVICE|DISPLAY|DOT|ELAPSED|EPS|ERASABLE|EXLINE|EXP|EXTERNAL|EXTYPE|FILETYPE|FIXED|FP|GO|GRAPH|HANDLER|IDN|IMAGE|IN|INT|INTERNAL|IP|IS|KEYED|LBOUND|LCASE|LEFT|LEN|LENGTH|LET|LINE|LINES|LOG|LOG10|LOG2|LTRIM|MARGIN|MAT|MAX|MAXNUM|MID|MIN|MISSING|MOD|NATIVE|NUL|NUMERIC|OF|OPTION|ORD|ORGANIZATION|OUTIN|OUTPUT|PI|POINT|POINTER|POINTS|POS|PRINT|PROGRAM|PROMPT|RAD|RADIANS|RANDOMIZE|RECORD|RECSIZE|RECTYPE|RELATIVE|REMAINDER|REPEAT|REST|RETRY|REWRITE|RIGHT|RND|ROUND|RTRIM|SAME|SEC|SELECT|SEQUENTIAL|SET|SETTER|SGN|SIN|SINH|SIZE|SKIP|SQR|STANDARD|STATUS|STR|STREAM|STYLE|TAB|TAN|TANH|TEMPLATE|TEXT|THERE|TIME|TIMEOUT|TRACE|TRANSFORM|TRUNCATE|UBOUND|UCASE|USE|VAL|VARIABLE|VIEWPORT|WHEN|WINDOW|WITH|ZER|ZONEWIDTH)(?:\$|\b)/i,operator:/<[=>]?|>=?|[+\-*\/^=&]|\b(?:AND|EQV|IMP|NOT|OR|XOR)\b/i,punctuation:/[,;:()]/}}E.exports=T,T.displayName="basic",T.aliases=[]},37253:(E,T,R)=>{var N=R(37260),I=R(54061);function O(E){E.register(N),E.register(I),E.languages["t4-vb"]=E.languages["t4-templating"].createT4("vbnet")}E.exports=O,O.displayName="t4Vb",O.aliases=[]},37260:E=>{function T(E){!function(E){function T(E,T,R){return{pattern:RegExp("<#"+E+"[\\s\\S]*?#>"),alias:"block",inside:{delimiter:{pattern:RegExp("^<#"+E+"|#>$"),alias:"important"},content:{pattern:/[\s\S]+/,inside:T,alias:R}}}}E.languages["t4-templating"]=Object.defineProperty({},"createT4",{value:function(R){var N=E.languages[R],I="language-"+R;return{block:{pattern:/<#[\s\S]+?#>/,inside:{directive:T("@",{"attr-value":{pattern:/=(?:("|')(?:\\[\s\S]|(?!\1)[^\\])*\1|[^\s'">=]+)/,inside:{punctuation:/^=|^["']|["']$/}},keyword:/\b\w+(?=\s)/,"attr-name":/\b\w+/}),expression:T("=",N,I),"class-feature":T("\\+",N,I),standard:T("",N,I)}}}}})}(E)}E.exports=T,T.displayName="t4Templating",T.aliases=[]},54061:(E,T,R)=>{var N=R(7208);function I(E){E.register(N),E.languages.vbnet=E.languages.extend("basic",{comment:[{pattern:/(?:!|REM\b).+/i,inside:{keyword:/^REM/i}},{pattern:/(^|[^\\:])'.*/,lookbehind:!0,greedy:!0}],string:{pattern:/(^|[^"])"(?:""|[^"])*"(?!")/,lookbehind:!0,greedy:!0},keyword:/(?:\b(?:ADDHANDLER|ADDRESSOF|ALIAS|AND|ANDALSO|AS|BEEP|BLOAD|BOOLEAN|BSAVE|BYREF|BYTE|BYVAL|CALL(?: ABSOLUTE)?|CASE|CATCH|CBOOL|CBYTE|CCHAR|CDATE|CDBL|CDEC|CHAIN|CHAR|CHDIR|CINT|CLASS|CLEAR|CLNG|CLOSE|CLS|COBJ|COM|COMMON|CONST|CONTINUE|CSBYTE|CSHORT|CSNG|CSTR|CTYPE|CUINT|CULNG|CUSHORT|DATA|DATE|DECIMAL|DECLARE|DEF(?: FN| SEG|DBL|INT|LNG|SNG|STR)|DEFAULT|DELEGATE|DIM|DIRECTCAST|DO|DOUBLE|ELSE|ELSEIF|END|ENUM|ENVIRON|ERASE|ERROR|EVENT|EXIT|FALSE|FIELD|FILES|FINALLY|FOR(?: EACH)?|FRIEND|FUNCTION|GET|GETTYPE|GETXMLNAMESPACE|GLOBAL|GOSUB|GOTO|HANDLES|IF|IMPLEMENTS|IMPORTS|IN|INHERITS|INPUT|INTEGER|INTERFACE|IOCTL|IS|ISNOT|KEY|KILL|LET|LIB|LIKE|LINE INPUT|LOCATE|LOCK|LONG|LOOP|LSET|ME|MKDIR|MOD|MODULE|MUSTINHERIT|MUSTOVERRIDE|MYBASE|MYCLASS|NAME|NAMESPACE|NARROWING|NEW|NEXT|NOT|NOTHING|NOTINHERITABLE|NOTOVERRIDABLE|OBJECT|OF|OFF|ON(?: COM| ERROR| KEY| TIMER)?|OPEN|OPERATOR|OPTION(?: BASE)?|OPTIONAL|OR|ORELSE|OUT|OVERLOADS|OVERRIDABLE|OVERRIDES|PARAMARRAY|PARTIAL|POKE|PRIVATE|PROPERTY|PROTECTED|PUBLIC|PUT|RAISEEVENT|READ|READONLY|REDIM|REM|REMOVEHANDLER|RESTORE|RESUME|RETURN|RMDIR|RSET|RUN|SBYTE|SELECT(?: CASE)?|SET|SHADOWS|SHARED|SHELL|SHORT|SINGLE|SLEEP|STATIC|STEP|STOP|STRING|STRUCTURE|SUB|SWAP|SYNCLOCK|SYSTEM|THEN|THROW|TIMER|TO|TROFF|TRON|TRUE|TRY|TRYCAST|TYPE|TYPEOF|UINTEGER|ULONG|UNLOCK|UNTIL|USHORT|USING|VIEW PRINT|WAIT|WEND|WHEN|WHILE|WIDENING|WITH|WITHEVENTS|WRITE|WRITEONLY|XOR)|\B(?:#CONST|#ELSE|#ELSEIF|#END|#IF))(?:\$|\b)/i,punctuation:/[,;:(){}]/})}E.exports=I,I.displayName="vbnet",I.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/53338.161bc4dd.chunk.js b/ydb/core/viewer/monitoring/static/js/53338.161bc4dd.chunk.js new file mode 100644 index 000000000000..6b98c8f9c673 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/53338.161bc4dd.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 53338.161bc4dd.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[53338],{53338:(e,s,t)=>{t.r(s),t.d(s,{conf:()=>n,language:()=>i});var n={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"'",close:"'",notIn:["string"]},{open:'"',close:'"',notIn:["string"]},{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"}]},i={defaultToken:"",tokenPostfix:".rq",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["add","as","asc","ask","base","by","clear","construct","copy","create","data","delete","desc","describe","distinct","drop","false","filter","from","graph","group","having","in","insert","limit","load","minus","move","named","not","offset","optional","order","prefix","reduced","select","service","silent","to","true","undef","union","using","values","where","with"],builtinFunctions:["a","abs","avg","bind","bnode","bound","ceil","coalesce","concat","contains","count","datatype","day","encode_for_uri","exists","floor","group_concat","hours","if","iri","isblank","isiri","isliteral","isnumeric","isuri","lang","langmatches","lcase","max","md5","min","minutes","month","now","rand","regex","replace","round","sameterm","sample","seconds","sha1","sha256","sha384","sha512","str","strafter","strbefore","strdt","strends","strlang","strlen","strstarts","struuid","substr","sum","timezone","tz","ucase","uri","uuid","year"],ignoreCase:!0,tokenizer:{root:[[/<[^\s\u00a0>]*>?/,"tag"],{include:"@strings"},[/#.*/,"comment"],[/[{}()\[\]]/,"@brackets"],[/[;,.]/,"delimiter"],[/[_\w\d]+:(\.(?=[\w_\-\\%])|[:\w_-]|\\[-\\_~.!$&'()*+,;=/?#@%]|%[a-f\d][a-f\d])*/,"tag"],[/:(\.(?=[\w_\-\\%])|[:\w_-]|\\[-\\_~.!$&'()*+,;=/?#@%]|%[a-f\d][a-f\d])+/,"tag"],[/[$?]?[_\w\d]+/,{cases:{"@keywords":{token:"keyword"},"@builtinFunctions":{token:"predefined.sql"},"@default":"identifier"}}],[/\^\^/,"operator.sql"],[/\^[*+\-<>=&|^\/!?]*/,"operator.sql"],[/[*+\-<>=&|\/!?]/,"operator.sql"],[/@[a-z\d\-]*/,"metatag.html"],[/\s+/,"white"]],strings:[[/'([^'\\]|\\.)*$/,"string.invalid"],[/'$/,"string.sql","@pop"],[/'/,"string.sql","@stringBody"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"$/,"string.sql","@pop"],[/"/,"string.sql","@dblStringBody"]],stringBody:[[/[^\\']+/,"string.sql"],[/\\./,"string.escape"],[/'/,"string.sql","@pop"]],dblStringBody:[[/[^\\"]+/,"string.sql"],[/\\./,"string.escape"],[/"/,"string.sql","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5454.e8f64f1a.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/53338.161bc4dd.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5454.e8f64f1a.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/53338.161bc4dd.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/535.ee345954.chunk.js b/ydb/core/viewer/monitoring/static/js/535.ee345954.chunk.js deleted file mode 100644 index f24b8b0f8bb9..000000000000 --- a/ydb/core/viewer/monitoring/static/js/535.ee345954.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[535],{90053:(e,t,a)=>{a.d(t,{E:()=>v});var n=a(8873),l=a(84476),s=a(24555),i=a(21334),o=a(77506),r=a(90182),d=a(48372);const c=JSON.parse('{"None":"None","15 sec":"15 sec","1 min":"1 min","2 min":"2 min","5 min":"5 min","Refresh":"Refresh"}'),u=(0,d.g4)("ydb-diagnostics-autorefresh-control",{en:c});var h=a(60712);const m=(0,o.cn)("auto-refresh-control");function v({className:e}){const t=(0,r.YQ)(),[a,o]=(0,r.Nt)();return(0,h.jsxs)("div",{className:m(null,e),children:[(0,h.jsx)(l.$,{view:"flat-secondary",onClick:()=>{t(i.F.util.invalidateTags(["All"]))},extraProps:{"aria-label":u("Refresh")},children:(0,h.jsx)(l.$.Icon,{children:(0,h.jsx)(n.A,{})})}),(0,h.jsxs)(s.l,{value:[String(a)],onUpdate:e=>{o(Number(e))},width:85,qa:"ydb-autorefresh-select",children:[(0,h.jsx)(s.l.Option,{value:"0",children:u("None")}),(0,h.jsx)(s.l.Option,{value:"15000",children:u("15 sec")}),(0,h.jsx)(s.l.Option,{value:"60000",children:u("1 min")}),(0,h.jsx)(s.l.Option,{value:"120000",children:u("2 min")}),(0,h.jsx)(s.l.Option,{value:"300000",children:u("5 min")})]})]})}},22983:(e,t,a)=>{a.d(t,{B:()=>d});var n=a(59284),l=a(84476),s=a(84375),i=a(55974),o=a(42829),r=a(60712);function d({children:e,onConfirmAction:t,onConfirmActionSuccess:a,dialogHeader:d,dialogText:c,retryButtonText:u,buttonDisabled:h=!1,buttonView:m="action",buttonTitle:v,buttonClassName:p,withPopover:b=!1,popoverContent:g,popoverPlacement:x="right",popoverDisabled:f=!0}){const[y,j]=n.useState(!1),[w,N]=n.useState(!1),[S,T]=n.useState(!1),_=()=>(0,r.jsx)(l.$,{onClick:()=>j(!0),view:m,disabled:h,loading:!h&&w,className:p,title:v,children:e});return(0,r.jsxs)(n.Fragment,{children:[(0,r.jsx)(i.g,{visible:y,header:d,text:c,withRetry:S,retryButtonText:u,onConfirm:async e=>{N(!0),await t(e)},onConfirmActionSuccess:async()=>{T(!1);try{await(null===a||void 0===a?void 0:a())}finally{N(!1)}},onConfirmActionError:e=>{T((0,o.D)(e)),N(!1)},onClose:()=>{j(!1)}}),b?(0,r.jsx)(s.A,{content:g,placement:x,disabled:f,children:_()}):_()]})}},55974:(e,t,a)=>{a.d(t,{g:()=>g});var n=a(59284),l=a(18677),s=a(71153),i=a(74321),o=a(2198),r=a(99991),d=a(89954),c=a(77506),u=a(48372);const h=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),m=(0,u.g4)("ydb-critical-action-dialog",{en:h});var v=a(60712);const p=(0,c.cn)("ydb-critical-dialog"),b=e=>e.data&&"issues"in e.data&&e.data.issues?(0,v.jsx)(d.O,{hideSeverity:!0,data:e.data}):403===e.status?m("no-rights-error"):e.statusText?e.statusText:m("default-error");function g({visible:e,header:t,text:a,withRetry:d,retryButtonText:c,withCheckBox:u,onClose:h,onConfirm:g,onConfirmActionSuccess:x,onConfirmActionError:f}){const[y,j]=n.useState(!1),[w,N]=n.useState(),[S,T]=n.useState(!1),_=async e=>(j(!0),g(e).then((()=>{x(),h()})).catch((e=>{f(e),N(e)})).finally((()=>{j(!1)})));return(0,v.jsx)(o.l,{open:e,hasCloseButton:!1,className:p(),size:"s",onClose:h,onTransitionExited:()=>{N(void 0),T(!1)},children:w?(0,v.jsxs)(n.Fragment,{children:[(0,v.jsx)(o.l.Header,{caption:t}),(0,v.jsx)(o.l.Body,{className:p("body"),children:(0,v.jsxs)("div",{className:p("body-message",{error:!0}),children:[(0,v.jsx)("span",{className:p("error-icon"),children:(0,v.jsx)(l.A,{width:"24",height:"22"})}),b(w)]})}),(0,v.jsx)(o.l.Footer,{loading:!1,preset:"default",textButtonApply:d?c||m("button-retry"):void 0,textButtonCancel:m("button-close"),onClickButtonApply:()=>_(!0),onClickButtonCancel:h})]}):(0,v.jsxs)(n.Fragment,{children:[(0,v.jsx)(o.l.Header,{caption:t}),(0,v.jsxs)(o.l.Body,{className:p("body"),children:[(0,v.jsxs)("div",{className:p("body-message",{warning:!0}),children:[(0,v.jsx)("span",{className:p("warning-icon"),children:(0,v.jsx)(r.I,{data:s.A,size:24})}),a]}),u?(0,v.jsx)(i.S,{checked:S,onUpdate:T,children:m("checkbox-text")}):null]}),(0,v.jsx)(o.l.Footer,{loading:y,preset:"default",textButtonApply:m("button-confirm"),textButtonCancel:m("button-cancel"),propsButtonApply:{type:"submit",disabled:u&&!S},onClickButtonCancel:h,onClickButtonApply:()=>_()})]})})}},42829:(e,t,a)=>{a.d(t,{D:()=>n});const n=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},3685:(e,t,a)=>{a.d(t,{$:()=>o});var n=a(77506),l=a(33775),s=a(60712);const i=(0,n.cn)("ydb-entity-page-title");function o({entityName:e,status:t,id:a,className:n}){return(0,s.jsxs)("div",{className:i(null,n),children:[(0,s.jsx)("span",{className:i("prefix"),children:e}),(0,s.jsx)(l.k,{className:i("icon"),status:t,size:"s"}),a]})}},10508:(e,t,a)=>{a.d(t,{c:()=>u});var n=a(67884),l=a(96873),s=a(54090),i=a(77506),o=a(82015),r=a(33775),d=a(60712);const c=(0,i.cn)("entity-status");function u({status:e=s.m.Grey,name:t="",label:a,path:i,iconPath:u,size:h="s",mode:m="color",showStatus:v=!0,externalLink:p=!1,withLeftTrim:b=!1,hasClipboardButton:g,clipboardButtonAlwaysVisible:x=!1,className:f}){const y=()=>v?(0,d.jsx)(r.k,{className:c("icon"),status:e,size:h,mode:m}):null;return(0,d.jsxs)("div",{className:c(null,f),children:[u?(j=u,(0,d.jsx)(n.N,{target:"_blank",href:j,children:y()})):y(),a&&(0,d.jsx)("span",{title:a,className:c("label",{size:h,state:e.toLowerCase()}),children:a}),(i||t)&&(0,d.jsxs)("div",{className:c("wrapper",{"with-button":g}),children:[(0,d.jsx)("span",{className:c("link",{"with-left-trim":b}),title:t,children:i?p?(0,d.jsx)(n.N,{className:c("name"),href:i,children:t}):(0,d.jsx)(o.E,{className:c("name"),to:i,children:t}):t&&(0,d.jsx)("span",{className:c("name"),children:t})}),g&&(0,d.jsx)("div",{className:c("controls-wrapper",{visible:x}),children:(0,d.jsx)(l.b,{text:t,size:"xs",view:"normal",className:c("clipboard-button",{visible:x})})})]})]});var j}},58389:(e,t,a)=>{a.d(t,{B:()=>c});var n=a(87184),l=a(77506),s=a(90053),i=a(70043),o=a(60712);const r=(0,l.cn)("ydb-page-meta");function d({items:e,loading:t}){return(0,o.jsx)("div",{className:r("info"),children:t?(0,o.jsx)(i.E,{className:r("skeleton")}):e.filter((e=>Boolean(e))).join("\xa0\xa0\xb7\xa0\xa0")})}function c({className:e,...t}){return(0,o.jsxs)(n.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:r(null,e),children:[(0,o.jsx)(d,{...t}),(0,o.jsx)(s.E,{})]})}},17594:(e,t,a)=>{a.d(t,{l:()=>d});var n=a(69024),l=a(4557),s=a(77506),i=a(16819),o=a(60712);const r=(0,s.cn)("ydb-resizeable-data-table");function d({columnsWidthLSKey:e,columns:t,settings:a,wrapperClassName:s,...d}){const[c,u]=(0,i.a)(e),h=(0,n.j)(t,c),m={...a,defaultResizeable:!0};return(0,o.jsx)("div",{className:r(null,s),children:(0,o.jsx)(l.Ay,{theme:"yandex-cloud",columns:h,onResize:u,settings:m,...d})})}},70043:(e,t,a)=>{a.d(t,{E:()=>i});var n=a(89169),l=a(66781),s=a(60712);const i=({delay:e=600,className:t})=>{const[a]=(0,l.y)(e);return a?(0,s.jsx)(n.E,{className:t}):null}},33775:(e,t,a)=>{a.d(t,{k:()=>h});var n=a(45720),l=a(16929),s=a(71153),i=a(99991),o=a(54090),r=a(77506),d=a(60712);const c=(0,r.cn)("ydb-status-icon"),u={[o.m.Blue]:n.A,[o.m.Yellow]:l.A,[o.m.Orange]:s.A,[o.m.Red]:l.A};function h({status:e=o.m.Grey,size:t="s",mode:a="color",className:n}){const l={state:e.toLowerCase(),size:t};return"icons"===a&&e in u?(0,d.jsx)(i.I,{className:c("status-icon",l,n),data:u[e]}):(0,d.jsx)("div",{className:c("status-color",l,n)})}},79737:(e,t,a)=>{a.d(t,{A:()=>o,X:()=>r});var n=a(5874),l=a(77506),s=a(60712);const i=(0,l.cn)("ydb-table");function o({children:e,className:t}){return(0,s.jsx)("div",{className:i("table-header-content",t),children:e})}function r({className:e,width:t,wrapperClassName:a,...l}){return(0,s.jsx)("div",{className:i(null,a),children:(0,s.jsx)(n.W,{headerCellClassName:({column:e})=>{var t;const a=null===(t=e.columnDef.meta)||void 0===t?void 0:t.align;return i("table-header-cell",{align:a})},cellClassName:e=>{var t,a;const n=null===e||void 0===e||null===(t=e.column.columnDef.meta)||void 0===t?void 0:t.align,l=null===e||void 0===e||null===(a=e.column.columnDef.meta)||void 0===a?void 0:a.verticalAlign;return i("table-cell",{align:n,"vertical-align":l})},className:i("table",{width:t},e),...l})})}},27775:(e,t,a)=>{a.d(t,{i:()=>i});var n=a(47665),l=a(58267),s=a(60712);function i({state:e}){return(0,s.jsx)(n.J,{theme:(0,l._)(e),children:e})}},47584:(e,t,a)=>{a.r(t),a.d(t,{Tablet:()=>be});var n=a(59284),l=a(87184),s=a(23871),i=a(44992),o=a(61750),r=a(10755),d=a(67087),c=a(370),u=a(7889),h=a(3685),m=a(44508),v=a(44294),p=a(98167),b=a(58389),g=a(92459),x=a(78668),f=a(40174),y=a(21545),j=a(54090),w=a(77506),N=a(76086),S=a(90182),T=a(76938),_=a(66528);const I=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",d:"M13.756 10.164c1.665-.962 1.665-3.366 0-4.328L5.251.919C3.584-.045 1.5 1.158 1.5 3.083v9.834c0 1.925 2.084 3.128 3.751 2.164z"}));var C=a(99991),A=a(22983),k=a(6354),D=a(48372);const E=JSON.parse('{"tablet.header":"Tablet","tablet.meta-database":"Database","tablet.meta-follower":"Follower","controls.kill":"Restart","controls.stop":"Stop","controls.resume":"Resume","controls.kill-not-allowed":"You don\'t have enough rights to restart tablet","controls.stop-not-allowed":"You don\'t have enough rights to stop tablet","controls.resume-not-allowed":"You don\'t have enough rights to resume tablet","dialog.kill-header":"Restart tablet","dialog.stop-header":"Stop tablet","dialog.resume-header":"Resume tablet","dialog.kill-text":"The tablet will be restarted. Do you want to proceed?","dialog.stop-text":"The tablet will be stopped. Do you want to proceed?","dialog.resume-text":"The tablet will be resumed. Do you want to proceed?","emptyState":"The tablet was not found","label_tablet-history":"Tablets","label_tablet-channels":"Storage"}'),B=(0,D.g4)("ydb-tablet-page",{en:E});function R(e){return Boolean(e&&"0"!==e)}var F=a(60712);const z=({tablet:e})=>{const{TabletId:t,HiveId:a}=e,s=(0,S.N4)(x._5),[i]=y.X.useKillTabletMutation(),[o]=y.X.useStopTabletMutation(),[r]=y.X.useResumeTabletMutation();if(!t)return null;const d=R(a),c=e.State===k.r.Stopped,u=e.State!==k.r.Stopped&&e.State!==k.r.Dead,h=e.State===k.r.Stopped||e.State===k.r.Deleted;return(0,F.jsxs)(l.s,{gap:2,wrap:"nowrap",children:[(0,F.jsxs)(A.B,{dialogHeader:B("dialog.kill-header"),dialogText:B("dialog.kill-text"),onConfirmAction:()=>i({id:t}).unwrap(),buttonDisabled:c||!s,withPopover:!0,buttonView:"normal",popoverContent:B("controls.kill-not-allowed"),popoverPlacement:"bottom",popoverDisabled:s,children:[(0,F.jsx)(C.I,{data:T.A}),B("controls.kill")]}),d&&(0,F.jsxs)(n.Fragment,{children:[(0,F.jsxs)(A.B,{dialogHeader:B("dialog.stop-header"),dialogText:B("dialog.stop-text"),onConfirmAction:()=>o({id:t,hiveId:a}).unwrap(),buttonDisabled:h||!s,withPopover:!0,buttonView:"normal",popoverContent:B("controls.stop-not-allowed"),popoverPlacement:"bottom",popoverDisabled:s,children:[(0,F.jsx)(C.I,{data:_.A}),B("controls.stop")]}),(0,F.jsxs)(A.B,{dialogHeader:B("dialog.resume-header"),dialogText:B("dialog.resume-text"),onConfirmAction:()=>r({id:t,hiveId:a}).unwrap(),buttonDisabled:u||!s,withPopover:!0,buttonView:"normal",popoverContent:B("controls.resume-not-allowed"),popoverPlacement:"bottom",popoverDisabled:s,children:[(0,F.jsx)(C.I,{data:I}),B("controls.resume")]})]})]})};var O=a(52905),P=a(60073),L=a(25196),G=a(27775),H=a(41826),q=a(31684),$=a(29819);const M=JSON.parse('{"field_scheme-shard":"SchemeShard","field_follower":"Follower","field_generation":"Generation","field_hive":"HiveId","field_state":"State","field_uptime":"Uptime","field_node":"Node","field_links":"Links","field_developer-ui-app":"App","field_developer-ui-counters":"Counters","field_developer-ui-executor":"Executor DB internals","field_developer-ui-state":"State Storage","title_info":"Info","title_links":"Links"}'),Y=(0,D.g4)("ydb-tablet-info",{en:M}),K=(0,w.cn)("ydb-tablet-info"),V=({tablet:e})=>{const t=(0,S.N4)(x._5),{ChangeTime:a,Generation:n,FollowerId:s,NodeId:i,HiveId:o,State:r,TenantId:{SchemeShard:d}={},TabletId:c}=e,u=R(o),h=r===k.r.Active,m=[];u&&m.push({label:Y("field_hive"),value:(0,F.jsx)(O.N_,{to:(0,g.DM)(o),className:K("link"),children:o})}),d&&m.push({label:Y("field_scheme-shard"),value:(0,F.jsx)(O.N_,{to:(0,g.DM)(d),className:K("link"),children:d})}),m.push({label:Y("field_state"),value:(0,F.jsx)(G.i,{state:r})}),h&&m.push({label:Y("field_uptime"),value:(0,F.jsx)(H.H,{ChangeTime:a})}),m.push({label:Y("field_generation"),value:n},{label:Y("field_node"),value:(0,F.jsx)(O.N_,{className:K("link"),to:(0,$.vI)(String(i)),children:i})}),s&&m.push({label:Y("field_follower"),value:s});return(0,F.jsxs)(l.s,{gap:10,wrap:"nowrap",children:[(0,F.jsxs)("div",{children:[(0,F.jsx)("div",{className:K("section-title"),children:Y("title_info")}),(0,F.jsx)(P.z_,{info:m})]}),t&&c?(0,F.jsxs)("div",{children:[(0,F.jsx)("div",{className:K("section-title"),children:Y("title_links")}),(0,F.jsxs)(l.s,{direction:"column",gap:3,children:[(0,F.jsx)(L.K,{title:Y("field_developer-ui-app"),url:(0,q._t)(c,"app")}),(0,F.jsx)(L.K,{title:Y("field_developer-ui-counters"),url:(0,q._t)(c,"counters")}),(0,F.jsx)(L.K,{title:Y("field_developer-ui-executor"),url:(0,q._t)(c,"executorInternals")}),(0,F.jsx)(L.K,{title:Y("field_developer-ui-state"),url:(0,q._t)(c,void 0,"SsId")})]})]}):null]})};var Q=a(36590),X=a(79737),J=a(84476),W=a(33705),U=a(56839);const Z=JSON.parse('{"label_channel-index":"Channel","label_storage-pool":"Storage Pool Name","label_group-id":"Group ID","label_generation":"From generation","label_timestamp":"Timestamp"}'),ee=(0,D.g4)("ydb-tablet-storage-info",{en:Z}),te=(0,w.cn)("ydb-tablet-storage-info");function ae(e,t){const a=e.getValue(),n="function"===typeof t?t(a):a;return(0,F.jsx)("div",{className:te("metrics-cell"),children:n})}function ne({row:e,name:t,hasExpand:a}){const n=e.getCanExpand();return(0,F.jsxs)(l.s,{gap:1,alignItems:"flex-start",className:te("name-wrapper"),children:[n&&(0,F.jsx)(J.$,{view:"flat",size:"xs",onClick:e.getToggleExpandedHandler(),children:(0,F.jsx)(J.$.Icon,{children:(0,F.jsx)(W.I,{direction:e.getIsExpanded()?"bottom":"right",size:14})})}),(0,F.jsx)("div",{className:te("name-content",{"no-control":a&&!n}),children:t})]})}function le({data:e}){const[t,a]=n.useState({}),l=n.useMemo((()=>function(e){var t;if(!e)return[];const{BoundChannels:a,TabletStorageInfo:n={}}=e,l=null!==(t=n.Channels)&&void 0!==t?t:[],s=[];for(const o of l){var i;const e=o.Channel,t=o.History;if(!e||!t||!t.length)continue;const n=[...t];n.reverse();const[l,...r]=n,d={...l,storagePoolName:null===a||void 0===a||null===(i=a[e])||void 0===i?void 0:i.StoragePoolName,channelIndex:e,children:r};s.push(d)}return s}(e)),[e]),s=n.useMemo((()=>l.some((e=>{var t;return null===(t=e.children)||void 0===t?void 0:t.length}))),[l]),i=n.useMemo((()=>{return e=s,[{accessorKey:"channelIndex",header:()=>(0,F.jsx)(X.A,{children:ee("label_channel-index")}),size:50,cell:ae,meta:{align:"right"}},{accessorKey:"storagePoolName",header:()=>(0,F.jsx)(X.A,{children:ee("label_storage-pool")}),size:200,cell:ae},{accessorKey:"GroupID",header:()=>(0,F.jsx)(X.A,{className:e?te("with-padding"):void 0,children:ee("label_group-id")}),size:100,cell:t=>(0,F.jsx)(ne,{row:t.row,name:t.getValue(),hasExpand:e})},{accessorKey:"FromGeneration",header:()=>(0,F.jsx)(X.A,{children:ee("label_generation")}),size:100,cell:ae,meta:{align:"right"}},{accessorKey:"Timestamp",header:()=>(0,F.jsx)(X.A,{children:ee("label_timestamp")}),size:200,cell:e=>ae(e,U.Ey),meta:{align:"right"}}];var e}),[s]),o=(0,Q.K)({columns:i,data:l,getSubRows:e=>e.children,enableExpanding:!0,onExpandedChange:a,state:{expanded:t}});return(0,F.jsx)(X.X,{table:o})}var se=a(4557),ie=a(10508),oe=a(82015),re=a(17594);const de=[{name:"Generation",align:se.Ay.RIGHT,render:({row:e})=>e.generation},{name:"Change time",align:se.Ay.RIGHT,sortable:!1,render:({row:e})=>(0,F.jsx)(H.H,{ChangeTime:e.changeTime}),width:120},{name:"State",sortable:!1,render:({row:e})=>(0,F.jsx)(G.i,{state:e.state})},{name:"Follower ID",sortable:!1,render:({row:e})=>e.leader?"leader":e.followerId},{name:"Node ID",align:se.Ay.RIGHT,sortable:!1,render:({row:e})=>(0,F.jsx)(oe.E,{to:(0,$.vI)(e.nodeId),children:e.nodeId})},{name:"Node FQDN",sortable:!1,width:300,render:({row:e})=>e.fqdn?(0,F.jsx)(ie.c,{name:e.fqdn,showStatus:!1,hasClipboardButton:!0}):(0,F.jsx)("span",{children:"\u2014"})}],ce={displayIndices:!1},ue=({history:e})=>(0,F.jsx)(re.l,{columnsWidthLSKey:"tabletTableColumnsWidth",data:e,columns:de,settings:ce,initialSortOrder:{columnId:"Generation",order:se.Ay.DESCENDING}}),he=(0,w.cn)("ydb-tablet-page"),me={history:"history",channels:"channels"},ve=[{id:me.history,get title(){return B("label_tablet-history")}},{id:me.channels,get title(){return B("label_tablet-channels")},isAdvanced:!0}],pe=c.z.nativeEnum(me).catch(me.history);function be(){var e;const t=(0,S.YQ)(),{id:a}=(0,r.g)(),[{database:s,clusterName:c}]=(0,d.useQueryParams)(g.qc),[u]=(0,S.Nt)(),{currentData:h,isFetching:v,error:x}=y.X.useGetTabletQuery({id:a,database:null!==s&&void 0!==s?s:void 0},{pollingInterval:u}),j=v&&void 0===h,{data:w={},history:T=[]}=h||{},{currentData:_}=y.X.useGetTabletDescribeQuery(w.TenantId?{tenantId:w.TenantId}:i.hT),I=null!==(e=_||s)&&void 0!==e?e:void 0,C=w.Type;n.useEffect((()=>{t((0,f.g)("tablet",{tenantName:null!==s&&void 0!==s?s:void 0,tabletId:a,tabletType:C}))}),[t,s,a,C]);const{Leader:A,Type:k}=w,D=[];return I&&D.push(`${B("tablet.meta-database")}: ${I}`),k&&D.push(k),!1===A&&D.push(B("tablet.meta-follower").toUpperCase()),(0,F.jsxs)(l.s,{gap:5,direction:"column",className:he(),children:[(0,F.jsx)(o.mg,{children:(0,F.jsx)("title",{children:`${a} \u2014 ${B("tablet.header")} \u2014 ${I||c||N.QM}`})}),(0,F.jsx)(b.B,{items:D}),(0,F.jsxs)(p.r,{loading:j,size:"l",children:[x?(0,F.jsx)(m.o,{error:x}):null,h?(0,F.jsx)(ge,{id:a,tablet:w,history:T}):null]})]})}function ge({id:e,tablet:t,history:a}){const n=!Object.keys(t).length,{Overall:s,HiveId:i}=t;return(0,F.jsxs)(u.q,{title:B("emptyState"),className:he("placeholder"),isEmpty:n,children:[(0,F.jsxs)(l.s,{gap:5,direction:"column",children:[(0,F.jsx)(h.$,{entityName:B("tablet.header"),status:null!==s&&void 0!==s?s:j.m.Grey,id:e}),(0,F.jsx)(z,{tablet:t}),(0,F.jsx)(V,{tablet:t})]}),(0,F.jsx)(xe,{id:e,hiveId:i,history:a})]})}function xe({id:e,hiveId:t,history:a}){var i;const[{activeTab:o,...r},c]=(0,d.useQueryParams)(g.qc),u=!(0,S.N4)(x._5)||!R(t);let h=pe.parse(o);return u&&null!==(i=ve.find((e=>e.id===h)))&&void 0!==i&&i.isAdvanced&&(h=me.history),n.useEffect((()=>{o!==h&&c({activeTab:h},"replaceIn")}),[o,h,c]),(0,F.jsxs)(l.s,{gap:5,direction:"column",children:[(0,F.jsx)("div",{children:(0,F.jsx)(s.t,{size:"l",items:ve.filter((({isAdvanced:e})=>!e||!u)),activeTab:h,wrapTo:(t,a)=>{const n=(0,g.DM)(e,{...r,activeTab:t.id});return(0,F.jsx)(v.E,{to:n,children:a},t.id)}})}),"history"===h?(0,F.jsx)(ue,{history:a}):null,"channels"!==h||u?null:(0,F.jsx)(fe,{id:e,hiveId:t})]})}function fe({id:e,hiveId:t}){const[a]=(0,S.Nt)(),{currentData:n,error:l,isFetching:s}=y.X.useGetAdvancedTableInfoQuery({id:e,hiveId:t},{pollingInterval:a}),i=s&&void 0===n;return(0,F.jsxs)(p.r,{loading:i,size:"l",children:[l?(0,F.jsx)(m.o,{error:l}):null,n?(0,F.jsx)(le,{data:n}):null]})}},89954:(e,t,a)=>{a.d(t,{O:()=>_});var n=a(59284),l=a(45720),s=a(16929),i=a(71153),o=a(18677),r=a(84476),d=a(33705),c=a(67884),u=a(99991),h=a(77506),m=a(48372);const v=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),p=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),b=(0,m.g4)("ydb-shorty-string",{ru:p,en:v});var g=a(60712);const x=(0,h.cn)("kv-shorty-string");function f({value:e="",limit:t=200,strict:a=!1,displayLength:l=!0,render:s=e=>e,onToggle:i,expandLabel:o=b("default_expand_label"),collapseLabel:r=b("default_collapse_label")}){const[d,u]=n.useState(!1),h=(d?r:o)+(l&&!d?b("chars_count",{count:e.length}):""),m=e.length>t+(a?0:h.length),v=d||!m?e:e.slice(0,t-4)+"\xa0...";return(0,g.jsxs)("div",{className:x(),children:[s(v),m?(0,g.jsx)(c.N,{className:x("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),u((e=>!e)),null===i||void 0===i||i()},children:h}):null]})}var y=a(41650);const j=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function w(e){return function(e){return!!e&&void 0!==j[e]}(e)?j[e]:"S_INFO"}const N=(0,h.cn)("kv-result-issues"),S=(0,h.cn)("kv-issues"),T=(0,h.cn)("kv-issue");function _({data:e,hideSeverity:t}){const[a,l]=n.useState(!1),s="string"===typeof e||null===e||void 0===e?void 0:e.issues,i=Array.isArray(s)&&s.length>0;return(0,g.jsxs)("div",{className:N(),children:[(0,g.jsxs)("div",{className:N("error-message"),children:[(()=>{let a;if("string"===typeof e)a=e;else{var l,s;const i=w(null===e||void 0===e||null===(l=e.error)||void 0===l?void 0:l.severity);a=(0,g.jsxs)(n.Fragment,{children:[t?null:(0,g.jsxs)(n.Fragment,{children:[(0,g.jsx)(B,{severity:i})," "]}),(0,g.jsx)("span",{className:N("error-message-text"),children:null===e||void 0===e||null===(s=e.error)||void 0===s?void 0:s.message})]})}return a})(),i&&(0,g.jsx)(r.$,{view:"normal",onClick:()=>l(!a),children:a?"Hide details":"Show details"})]}),i&&a&&(0,g.jsx)(I,{hideSeverity:t,issues:s})]})}function I({issues:e,hideSeverity:t}){const a=null===e||void 0===e?void 0:e.reduce(((e,t)=>{var a;const n=null!==(a=t.severity)&&void 0!==a?a:10;return Math.min(e,n)}),10);return(0,g.jsx)("div",{className:S(null),children:null===e||void 0===e?void 0:e.map(((e,n)=>(0,g.jsx)(C,{hideSeverity:t,issue:e,expanded:e===a},n)))})}function C({issue:e,hideSeverity:t,level:a=0}){const[l,s]=n.useState(!0),i=w(e.severity),o=e.issues,c=Array.isArray(o)&&o.length>0,u=l?"bottom":"right";return(0,g.jsxs)("div",{className:T({leaf:!c,"has-issues":c}),children:[(0,g.jsxs)("div",{className:T("line"),children:[c&&(0,g.jsx)(r.$,{view:"flat-secondary",onClick:()=>s(!l),className:T("arrow-toggle"),children:(0,g.jsx)(d.I,{direction:u,size:16})}),t?null:(0,g.jsx)(B,{severity:i}),(0,g.jsx)(A,{issue:e}),e.issue_code?(0,g.jsxs)("span",{className:T("code"),children:["Code: ",e.issue_code]}):null]}),c&&l&&(0,g.jsx)("div",{className:T("issues"),children:(0,g.jsx)(k,{issues:o,level:a+1,expanded:l})})]})}function A({issue:e}){var t;const a=function(e){const{position:t}=e;if("object"!==typeof t||null===t||!(0,y.kf)(t.row))return"";const{row:a,column:n}=t;return(0,y.kf)(n)?`${a}:${n}`:`line ${a}`}(e),n=window.ydbEditor,l=()=>(0,g.jsxs)("span",{className:T("message"),children:[a&&(0,g.jsx)("span",{className:T("place-text"),title:"Position",children:a}),(0,g.jsx)("div",{className:T("message-text"),children:(0,g.jsx)(f,{value:e.message,expandLabel:"Show full message"})})]}),{row:s,column:i}=null!==(t=e.position)&&void 0!==t?t:{};if(!((0,y.kf)(s)&&n))return l();return(0,g.jsx)(c.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:s,column:null!==i&&void 0!==i?i:0};n.setPosition(e),n.revealPositionInCenterIfOutsideViewport(e),n.focus()},view:"primary",children:l()})}function k(e){const{issues:t,level:a,expanded:n}=e;return(0,g.jsx)("div",{className:T("list"),children:t.map(((e,t)=>(0,g.jsx)(C,{issue:e,level:a,expanded:n},t)))})}const D={S_INFO:l.A,S_WARNING:s.A,S_ERROR:i.A,S_FATAL:o.A},E=(0,h.cn)("yql-issue-severity");function B({severity:e}){const t=e.slice(2).toLowerCase();return(0,g.jsxs)("span",{className:E({severity:t}),children:[(0,g.jsx)(u.I,{className:E("icon"),data:D[e]}),(0,g.jsx)("span",{className:E("title"),children:t})]})}},21545:(e,t,a)=>{a.d(t,{X:()=>l});var n=a(78034);const l=a(21334).F.injectEndpoints({endpoints:e=>({getTablet:e.query({queryFn:async({id:e,database:t},{signal:a})=>{try{const[l,s,i]=await Promise.all([window.api.viewer.getTablet({id:e,database:t},{signal:a}),window.api.viewer.getTabletHistory({id:e,database:t},{signal:a}),window.api.viewer.getNodesList({signal:a})]),o=(0,n.nN)(i),r=Object.keys(s).reduce(((e,t)=>{var a;const n=null===(a=s[t])||void 0===a?void 0:a.TabletStateInfo;if(n&&n.length){var l;const a=n.find((e=>e.Leader))||n[0],{ChangeTime:s,Generation:i,State:r,Leader:d,FollowerId:c}=a,u=o&&t?null===(l=o.get(Number(t)))||void 0===l?void 0:l.Host:void 0;"Dead"!==r&&e.push({nodeId:t,generation:i,changeTime:s,state:r,leader:d,followerId:c,fqdn:u})}return e}),[]),{TabletStateInfo:d=[]}=l,[c={}]=d,{TabletId:u}=c;return{data:{id:u,data:c,history:r}}}catch(l){return{error:l}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),getTabletDescribe:e.query({queryFn:async({tenantId:e},{signal:t})=>{try{const a=await window.api.viewer.getTabletDescribe(e,{signal:t}),{SchemeShard:n,PathId:l}=e;return{data:(null===a||void 0===a?void 0:a.Path)||`${n}:${l}`}}catch(a){return{error:a}}},providesTags:["All"]}),getAdvancedTableInfo:e.query({queryFn:async({id:e,hiveId:t},{signal:a})=>{try{return{data:await window.api.tablets.getTabletFromHive({id:e,hiveId:t},{signal:a})}}catch(n){return{error:n}}},providesTags:(e,t,a)=>["All",{type:"Tablet",id:a.id}]}),killTablet:e.mutation({queryFn:async({id:e})=>{try{return{data:await window.api.tablets.killTablet(e)}}catch(t){return{error:t}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),stopTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.stopTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]}),resumeTablet:e.mutation({queryFn:async({id:e,hiveId:t})=>{try{return{data:await window.api.tablets.resumeTablet(e,t)}}catch(a){return{error:a}}},invalidatesTags:(e,t,a)=>[{type:"Tablet",id:a.id},{type:"Tablet",id:"LIST"}]})}),overrideExisting:"throw"})},16819:(e,t,a)=>{a.d(t,{a:()=>i});var n=a(59284),l=a(69024),s=a(59001);const i=e=>{const t=n.useCallback((()=>e?s.f.readUserSettingsValue(e,{}):{}),[e]),a=n.useCallback((t=>{e&&s.f.setUserSettingsValue(e,t)}),[e]);return(0,l.a)({saveSizes:a,getSizes:t})}},58267:(e,t,a)=>{a.d(t,{P:()=>i,_:()=>o});var n=a(54090),l=a(6354);const s={[l.r.Dead]:n.m.Red,[l.r.Created]:n.m.Yellow,[l.r.ResolveStateStorage]:n.m.Yellow,[l.r.Candidate]:n.m.Yellow,[l.r.BlockBlobStorage]:n.m.Yellow,[l.r.WriteZeroEntry]:n.m.Yellow,[l.r.Restored]:n.m.Yellow,[l.r.Discover]:n.m.Yellow,[l.r.Lock]:n.m.Yellow,[l.r.Stopped]:n.m.Yellow,[l.r.ResolveLeader]:n.m.Yellow,[l.r.RebuildGraph]:n.m.Yellow,[l.r.Deleted]:n.m.Green,[l.r.Active]:n.m.Green},i=e=>{if(!e)return n.m.Grey;return t=e,Object.values(n.m).includes(t)?e:s[e];var t};function o(e){if(!e)return"unknown";switch(e){case l.r.Dead:return"danger";case l.r.Active:case l.r.Deleted:return"success";default:return"warning"}}},16929:(e,t,a)=>{a.d(t,{A:()=>l});var n=a(59284);const l=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0m-6 2.5a1 1 0 1 1-2 0 1 1 0 0 1 2 0M8.75 5a.75.75 0 0 0-1.5 0v2.5a.75.75 0 0 0 1.5 0z",clipRule:"evenodd"}))},45720:(e,t,a)=>{a.d(t,{A:()=>l});var n=a(59284);const l=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14m1-9.5a1 1 0 1 1-2 0 1 1 0 0 1 2 0M8 7.75a.75.75 0 0 1 .75.75V11a.75.75 0 0 1-1.5 0V8.5A.75.75 0 0 1 8 7.75",clipRule:"evenodd"}))},71153:(e,t,a)=>{a.d(t,{A:()=>l});var n=a(59284);const l=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M5.835 2.244c.963-1.665 3.367-1.665 4.33 0l4.916 8.505c.964 1.666-.24 3.751-2.164 3.751H3.083c-1.925 0-3.128-2.085-2.165-3.751zM8 5a.75.75 0 0 1 .75.75v2a.75.75 0 1 1-1.5 0v-2A.75.75 0 0 1 8 5m1 5.75a1 1 0 1 1-2 0 1 1 0 0 1 2 0",clipRule:"evenodd"}))},89169:(e,t,a)=>{a.d(t,{E:()=>s});var n=a(59284);const l=(0,a(69220).om)("skeleton");function s({className:e,style:t,qa:a}){return n.createElement("div",{className:l(null,e),style:t,"data-qa":a})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/53672.a70ebf8e.chunk.js b/ydb/core/viewer/monitoring/static/js/53672.a70ebf8e.chunk.js new file mode 100644 index 000000000000..ebc35a470cf5 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/53672.a70ebf8e.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[53672],{53672:function(e,a,t){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=a(e);function u(e,a,t,u){var s={s:["m\xf5ne sekundi","m\xf5ni sekund","paar sekundit"],m:["\xfche minuti","\xfcks minut"],mm:["%d minuti","%d minutit"],h:["\xfche tunni","tund aega","\xfcks tund"],hh:["%d tunni","%d tundi"],d:["\xfche p\xe4eva","\xfcks p\xe4ev"],M:["kuu aja","kuu aega","\xfcks kuu"],MM:["%d kuu","%d kuud"],y:["\xfche aasta","aasta","\xfcks aasta"],yy:["%d aasta","%d aastat"]};return a?(s[t][2]?s[t][2]:s[t][1]).replace("%d",e):(u?s[t][0]:s[t][1]).replace("%d",e)}var s={name:"et",weekdays:"p\xfchap\xe4ev_esmasp\xe4ev_teisip\xe4ev_kolmap\xe4ev_neljap\xe4ev_reede_laup\xe4ev".split("_"),weekdaysShort:"P_E_T_K_N_R_L".split("_"),weekdaysMin:"P_E_T_K_N_R_L".split("_"),months:"jaanuar_veebruar_m\xe4rts_aprill_mai_juuni_juuli_august_september_oktoober_november_detsember".split("_"),monthsShort:"jaan_veebr_m\xe4rts_apr_mai_juuni_juuli_aug_sept_okt_nov_dets".split("_"),ordinal:function(e){return e+"."},weekStart:1,relativeTime:{future:"%s p\xe4rast",past:"%s tagasi",s:u,m:u,mm:u,h:u,hh:u,d:u,dd:"%d p\xe4eva",M:u,MM:u,y:u,yy:u},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm"}};return t.default.locale(s,null,!0),s}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5382.3a2e6ac6.chunk.js b/ydb/core/viewer/monitoring/static/js/5382.3a2e6ac6.chunk.js deleted file mode 100644 index 49501acf602e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5382.3a2e6ac6.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5382.3a2e6ac6.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5382],{35382:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>o});var i={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"'",close:"'"},{open:'"',close:'"'}],autoClosingPairs:[{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["comment"]},{open:'"""',close:'"""'},{open:"`",close:"`",notIn:["string","comment"]},{open:"(",close:")"},{open:"{",close:"}"},{open:"[",close:"]"},{open:"<<",close:">>"}],indentationRules:{increaseIndentPattern:/^\s*(after|else|catch|rescue|fn|[^#]*(do|<\-|\->|\{|\[|\=))\s*$/,decreaseIndentPattern:/^\s*((\}|\])\s*$|(after|else|catch|rescue|end)\b)/}},o={defaultToken:"source",tokenPostfix:".elixir",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"},{open:"<<",close:">>",token:"delimiter.angle.special"}],declarationKeywords:["def","defp","defn","defnp","defguard","defguardp","defmacro","defmacrop","defdelegate","defcallback","defmacrocallback","defmodule","defprotocol","defexception","defimpl","defstruct"],operatorKeywords:["and","in","not","or","when"],namespaceKeywords:["alias","import","require","use"],otherKeywords:["after","case","catch","cond","do","else","end","fn","for","if","quote","raise","receive","rescue","super","throw","try","unless","unquote_splicing","unquote","with"],constants:["true","false","nil"],nameBuiltin:["__MODULE__","__DIR__","__ENV__","__CALLER__","__STACKTRACE__"],operator:/-[->]?|!={0,2}|\*{1,2}|\/|\\\\|&{1,3}|\.\.?|\^(?:\^\^)?|\+\+?|<(?:-|<<|=|>|\|>|~>?)?|=~|={1,3}|>(?:=|>>)?|\|~>|\|>|\|{1,3}|~>>?|~~~|::/,variableName:/[a-z_][a-zA-Z0-9_]*[?!]?/,atomName:/[a-zA-Z_][a-zA-Z0-9_@]*[?!]?|@specialAtomName|@operator/,specialAtomName:/\.\.\.|<<>>|%\{\}|%|\{\}/,aliasPart:/[A-Z][a-zA-Z0-9_]*/,moduleName:/@aliasPart(?:\.@aliasPart)*/,sigilSymmetricDelimiter:/"""|'''|"|'|\/|\|/,sigilStartDelimiter:/@sigilSymmetricDelimiter|<|\{|\[|\(/,sigilEndDelimiter:/@sigilSymmetricDelimiter|>|\}|\]|\)/,sigilModifiers:/[a-zA-Z0-9]*/,decimal:/\d(?:_?\d)*/,hex:/[0-9a-fA-F](_?[0-9a-fA-F])*/,octal:/[0-7](_?[0-7])*/,binary:/[01](_?[01])*/,escape:/\\u[0-9a-fA-F]{4}|\\x[0-9a-fA-F]{2}|\\./,tokenizer:{root:[{include:"@whitespace"},{include:"@comments"},{include:"@keywordsShorthand"},{include:"@numbers"},{include:"@identifiers"},{include:"@strings"},{include:"@atoms"},{include:"@sigils"},{include:"@attributes"},{include:"@symbols"}],whitespace:[[/\s+/,"white"]],comments:[[/(#)(.*)/,["comment.punctuation","comment"]]],keywordsShorthand:[[/(@atomName)(:)(\s+)/,["constant","constant.punctuation","white"]],[/"(?=([^"]|#\{.*?\}|\\")*":)/,{token:"constant.delimiter",next:"@doubleQuotedStringKeyword"}],[/'(?=([^']|#\{.*?\}|\\')*':)/,{token:"constant.delimiter",next:"@singleQuotedStringKeyword"}]],doubleQuotedStringKeyword:[[/":/,{token:"constant.delimiter",next:"@pop"}],{include:"@stringConstantContentInterpol"}],singleQuotedStringKeyword:[[/':/,{token:"constant.delimiter",next:"@pop"}],{include:"@stringConstantContentInterpol"}],numbers:[[/0b@binary/,"number.binary"],[/0o@octal/,"number.octal"],[/0x@hex/,"number.hex"],[/@decimal\.@decimal([eE]-?@decimal)?/,"number.float"],[/@decimal/,"number"]],identifiers:[[/\b(defp?|defnp?|defmacrop?|defguardp?|defdelegate)(\s+)(@variableName)(?!\s+@operator)/,["keyword.declaration","white",{cases:{unquote:"keyword","@default":"function"}}]],[/(@variableName)(?=\s*\.?\s*\()/,{cases:{"@declarationKeywords":"keyword.declaration","@namespaceKeywords":"keyword","@otherKeywords":"keyword","@default":"function.call"}}],[/(@moduleName)(\s*)(\.)(\s*)(@variableName)/,["type.identifier","white","operator","white","function.call"]],[/(:)(@atomName)(\s*)(\.)(\s*)(@variableName)/,["constant.punctuation","constant","white","operator","white","function.call"]],[/(\|>)(\s*)(@variableName)/,["operator","white",{cases:{"@otherKeywords":"keyword","@default":"function.call"}}]],[/(&)(\s*)(@variableName)/,["operator","white","function.call"]],[/@variableName/,{cases:{"@declarationKeywords":"keyword.declaration","@operatorKeywords":"keyword.operator","@namespaceKeywords":"keyword","@otherKeywords":"keyword","@constants":"constant.language","@nameBuiltin":"variable.language","_.*":"comment.unused","@default":"identifier"}}],[/@moduleName/,"type.identifier"]],strings:[[/"""/,{token:"string.delimiter",next:"@doubleQuotedHeredoc"}],[/'''/,{token:"string.delimiter",next:"@singleQuotedHeredoc"}],[/"/,{token:"string.delimiter",next:"@doubleQuotedString"}],[/'/,{token:"string.delimiter",next:"@singleQuotedString"}]],doubleQuotedHeredoc:[[/"""/,{token:"string.delimiter",next:"@pop"}],{include:"@stringContentInterpol"}],singleQuotedHeredoc:[[/'''/,{token:"string.delimiter",next:"@pop"}],{include:"@stringContentInterpol"}],doubleQuotedString:[[/"/,{token:"string.delimiter",next:"@pop"}],{include:"@stringContentInterpol"}],singleQuotedString:[[/'/,{token:"string.delimiter",next:"@pop"}],{include:"@stringContentInterpol"}],atoms:[[/(:)(@atomName)/,["constant.punctuation","constant"]],[/:"/,{token:"constant.delimiter",next:"@doubleQuotedStringAtom"}],[/:'/,{token:"constant.delimiter",next:"@singleQuotedStringAtom"}]],doubleQuotedStringAtom:[[/"/,{token:"constant.delimiter",next:"@pop"}],{include:"@stringConstantContentInterpol"}],singleQuotedStringAtom:[[/'/,{token:"constant.delimiter",next:"@pop"}],{include:"@stringConstantContentInterpol"}],sigils:[[/~[a-z]@sigilStartDelimiter/,{token:"@rematch",next:"@sigil.interpol"}],[/~([A-Z]+)@sigilStartDelimiter/,{token:"@rematch",next:"@sigil.noInterpol"}]],sigil:[[/~([a-z]|[A-Z]+)\{/,{token:"@rematch",switchTo:"@sigilStart.$S2.$1.{.}"}],[/~([a-z]|[A-Z]+)\[/,{token:"@rematch",switchTo:"@sigilStart.$S2.$1.[.]"}],[/~([a-z]|[A-Z]+)\(/,{token:"@rematch",switchTo:"@sigilStart.$S2.$1.(.)"}],[/~([a-z]|[A-Z]+)\"}],[/~([a-z]|[A-Z]+)(@sigilSymmetricDelimiter)/,{token:"@rematch",switchTo:"@sigilStart.$S2.$1.$2.$2"}]],"sigilStart.interpol.s":[[/~s@sigilStartDelimiter/,{token:"string.delimiter",switchTo:"@sigilContinue.$S2.$S3.$S4.$S5"}]],"sigilContinue.interpol.s":[[/(@sigilEndDelimiter)@sigilModifiers/,{cases:{"$1==$S5":{token:"string.delimiter",next:"@pop"},"@default":"string"}}],{include:"@stringContentInterpol"}],"sigilStart.noInterpol.S":[[/~S@sigilStartDelimiter/,{token:"string.delimiter",switchTo:"@sigilContinue.$S2.$S3.$S4.$S5"}]],"sigilContinue.noInterpol.S":[[/(^|[^\\])\\@sigilEndDelimiter/,"string"],[/(@sigilEndDelimiter)@sigilModifiers/,{cases:{"$1==$S5":{token:"string.delimiter",next:"@pop"},"@default":"string"}}],{include:"@stringContent"}],"sigilStart.interpol.r":[[/~r@sigilStartDelimiter/,{token:"regexp.delimiter",switchTo:"@sigilContinue.$S2.$S3.$S4.$S5"}]],"sigilContinue.interpol.r":[[/(@sigilEndDelimiter)@sigilModifiers/,{cases:{"$1==$S5":{token:"regexp.delimiter",next:"@pop"},"@default":"regexp"}}],{include:"@regexpContentInterpol"}],"sigilStart.noInterpol.R":[[/~R@sigilStartDelimiter/,{token:"regexp.delimiter",switchTo:"@sigilContinue.$S2.$S3.$S4.$S5"}]],"sigilContinue.noInterpol.R":[[/(^|[^\\])\\@sigilEndDelimiter/,"regexp"],[/(@sigilEndDelimiter)@sigilModifiers/,{cases:{"$1==$S5":{token:"regexp.delimiter",next:"@pop"},"@default":"regexp"}}],{include:"@regexpContent"}],"sigilStart.interpol":[[/~([a-z]|[A-Z]+)@sigilStartDelimiter/,{token:"sigil.delimiter",switchTo:"@sigilContinue.$S2.$S3.$S4.$S5"}]],"sigilContinue.interpol":[[/(@sigilEndDelimiter)@sigilModifiers/,{cases:{"$1==$S5":{token:"sigil.delimiter",next:"@pop"},"@default":"sigil"}}],{include:"@sigilContentInterpol"}],"sigilStart.noInterpol":[[/~([a-z]|[A-Z]+)@sigilStartDelimiter/,{token:"sigil.delimiter",switchTo:"@sigilContinue.$S2.$S3.$S4.$S5"}]],"sigilContinue.noInterpol":[[/(^|[^\\])\\@sigilEndDelimiter/,"sigil"],[/(@sigilEndDelimiter)@sigilModifiers/,{cases:{"$1==$S5":{token:"sigil.delimiter",next:"@pop"},"@default":"sigil"}}],{include:"@sigilContent"}],attributes:[[/\@(module|type)?doc (~[sS])?"""/,{token:"comment.block.documentation",next:"@doubleQuotedHeredocDocstring"}],[/\@(module|type)?doc (~[sS])?'''/,{token:"comment.block.documentation",next:"@singleQuotedHeredocDocstring"}],[/\@(module|type)?doc (~[sS])?"/,{token:"comment.block.documentation",next:"@doubleQuotedStringDocstring"}],[/\@(module|type)?doc (~[sS])?'/,{token:"comment.block.documentation",next:"@singleQuotedStringDocstring"}],[/\@(module|type)?doc false/,"comment.block.documentation"],[/\@(@variableName)/,"variable"]],doubleQuotedHeredocDocstring:[[/"""/,{token:"comment.block.documentation",next:"@pop"}],{include:"@docstringContent"}],singleQuotedHeredocDocstring:[[/'''/,{token:"comment.block.documentation",next:"@pop"}],{include:"@docstringContent"}],doubleQuotedStringDocstring:[[/"/,{token:"comment.block.documentation",next:"@pop"}],{include:"@docstringContent"}],singleQuotedStringDocstring:[[/'/,{token:"comment.block.documentation",next:"@pop"}],{include:"@docstringContent"}],symbols:[[/\?(\\.|[^\\\s])/,"number.constant"],[/&\d+/,"operator"],[/<<<|>>>/,"operator"],[/[()\[\]\{\}]|<<|>>/,"@brackets"],[/\.\.\./,"identifier"],[/=>/,"punctuation"],[/@operator/,"operator"],[/[:;,.%]/,"punctuation"]],stringContentInterpol:[{include:"@interpolation"},{include:"@escapeChar"},{include:"@stringContent"}],stringContent:[[/./,"string"]],stringConstantContentInterpol:[{include:"@interpolation"},{include:"@escapeChar"},{include:"@stringConstantContent"}],stringConstantContent:[[/./,"constant"]],regexpContentInterpol:[{include:"@interpolation"},{include:"@escapeChar"},{include:"@regexpContent"}],regexpContent:[[/(\s)(#)(\s.*)$/,["white","comment.punctuation","comment"]],[/./,"regexp"]],sigilContentInterpol:[{include:"@interpolation"},{include:"@escapeChar"},{include:"@sigilContent"}],sigilContent:[[/./,"sigil"]],docstringContent:[[/./,"comment.block.documentation"]],escapeChar:[[/@escape/,"constant.character.escape"]],interpolation:[[/#{/,{token:"delimiter.bracket.embed",next:"@interpolationContinue"}]],interpolationContinue:[[/}/,{token:"delimiter.bracket.embed",next:"@pop"}],{include:"@root"}]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5393.cb636c81.chunk.js b/ydb/core/viewer/monitoring/static/js/5393.cb636c81.chunk.js new file mode 100644 index 000000000000..2d4c10759c9e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/5393.cb636c81.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5393],{5393:(e,n,r)=>{r.d(n,{default:()=>i});var t=r(31418);const i=r.n(t)()},31418:e=>{function n(e){!function(e){var n=/(?:\B-|\b_|\b)[A-Za-z][\w-]*(?![\w-])/.source,r="(?:"+/\b(?:unsigned\s+)?long\s+long(?![\w-])/.source+"|"+/\b(?:unrestricted|unsigned)\s+[a-z]+(?![\w-])/.source+"|"+/(?!(?:unrestricted|unsigned)\b)/.source+n+/(?:\s*<(?:[^<>]|<[^<>]*>)*>)?/.source+")"+/(?:\s*\?)?/.source,t={};for(var i in e.languages["web-idl"]={comment:{pattern:/\/\/.*|\/\*[\s\S]*?\*\//,greedy:!0},string:{pattern:/"[^"]*"/,greedy:!0},namespace:{pattern:RegExp(/(\bnamespace\s+)/.source+n),lookbehind:!0},"class-name":[{pattern:/(^|[^\w-])(?:iterable|maplike|setlike)\s*<(?:[^<>]|<[^<>]*>)*>/,lookbehind:!0,inside:t},{pattern:RegExp(/(\b(?:attribute|const|deleter|getter|optional|setter)\s+)/.source+r),lookbehind:!0,inside:t},{pattern:RegExp("("+/\bcallback\s+/.source+n+/\s*=\s*/.source+")"+r),lookbehind:!0,inside:t},{pattern:RegExp(/(\btypedef\b\s*)/.source+r),lookbehind:!0,inside:t},{pattern:RegExp(/(\b(?:callback|dictionary|enum|interface(?:\s+mixin)?)\s+)(?!(?:interface|mixin)\b)/.source+n),lookbehind:!0},{pattern:RegExp(/(:\s*)/.source+n),lookbehind:!0},RegExp(n+/(?=\s+(?:implements|includes)\b)/.source),{pattern:RegExp(/(\b(?:implements|includes)\s+)/.source+n),lookbehind:!0},{pattern:RegExp(r+"(?="+/\s*(?:\.{3}\s*)?/.source+n+/\s*[(),;=]/.source+")"),inside:t}],builtin:/\b(?:ArrayBuffer|BigInt64Array|BigUint64Array|ByteString|DOMString|DataView|Float32Array|Float64Array|FrozenArray|Int16Array|Int32Array|Int8Array|ObservableArray|Promise|USVString|Uint16Array|Uint32Array|Uint8Array|Uint8ClampedArray)\b/,keyword:[/\b(?:async|attribute|callback|const|constructor|deleter|dictionary|enum|getter|implements|includes|inherit|interface|mixin|namespace|null|optional|or|partial|readonly|required|setter|static|stringifier|typedef|unrestricted)\b/,/\b(?:any|bigint|boolean|byte|double|float|iterable|long|maplike|object|octet|record|sequence|setlike|short|symbol|undefined|unsigned|void)\b/],boolean:/\b(?:false|true)\b/,number:{pattern:/(^|[^\w-])-?(?:0x[0-9a-f]+|(?:\d+(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?|NaN|Infinity)(?![\w-])/i,lookbehind:!0},operator:/\.{3}|[=:?<>-]/,punctuation:/[(){}[\].,;]/},e.languages["web-idl"])"class-name"!==i&&(t[i]=e.languages["web-idl"][i]);e.languages.webidl=e.languages["web-idl"]}(e)}e.exports=n,n.displayName="webIdl",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5401.dfb63825.chunk.js b/ydb/core/viewer/monitoring/static/js/5401.dfb63825.chunk.js deleted file mode 100644 index 8ab11e199899..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5401.dfb63825.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5401],{65401:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-ie",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5411.001c1dc7.chunk.js b/ydb/core/viewer/monitoring/static/js/5411.001c1dc7.chunk.js new file mode 100644 index 000000000000..34e89f3e06e0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/5411.001c1dc7.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5411],{5411:(e,$,t)=>{t.d($,{default:()=>n});var a=t(69004);const n=t.n(a)()},69004:e=>{function $(e){!function(e){var $=["$eq","$gt","$gte","$in","$lt","$lte","$ne","$nin","$and","$not","$nor","$or","$exists","$type","$expr","$jsonSchema","$mod","$regex","$text","$where","$geoIntersects","$geoWithin","$near","$nearSphere","$all","$elemMatch","$size","$bitsAllClear","$bitsAllSet","$bitsAnyClear","$bitsAnySet","$comment","$elemMatch","$meta","$slice","$currentDate","$inc","$min","$max","$mul","$rename","$set","$setOnInsert","$unset","$addToSet","$pop","$pull","$push","$pullAll","$each","$position","$slice","$sort","$bit","$addFields","$bucket","$bucketAuto","$collStats","$count","$currentOp","$facet","$geoNear","$graphLookup","$group","$indexStats","$limit","$listLocalSessions","$listSessions","$lookup","$match","$merge","$out","$planCacheStats","$project","$redact","$replaceRoot","$replaceWith","$sample","$set","$skip","$sort","$sortByCount","$unionWith","$unset","$unwind","$setWindowFields","$abs","$accumulator","$acos","$acosh","$add","$addToSet","$allElementsTrue","$and","$anyElementTrue","$arrayElemAt","$arrayToObject","$asin","$asinh","$atan","$atan2","$atanh","$avg","$binarySize","$bsonSize","$ceil","$cmp","$concat","$concatArrays","$cond","$convert","$cos","$dateFromParts","$dateToParts","$dateFromString","$dateToString","$dayOfMonth","$dayOfWeek","$dayOfYear","$degreesToRadians","$divide","$eq","$exp","$filter","$first","$floor","$function","$gt","$gte","$hour","$ifNull","$in","$indexOfArray","$indexOfBytes","$indexOfCP","$isArray","$isNumber","$isoDayOfWeek","$isoWeek","$isoWeekYear","$last","$last","$let","$literal","$ln","$log","$log10","$lt","$lte","$ltrim","$map","$max","$mergeObjects","$meta","$min","$millisecond","$minute","$mod","$month","$multiply","$ne","$not","$objectToArray","$or","$pow","$push","$radiansToDegrees","$range","$reduce","$regexFind","$regexFindAll","$regexMatch","$replaceOne","$replaceAll","$reverseArray","$round","$rtrim","$second","$setDifference","$setEquals","$setIntersection","$setIsSubset","$setUnion","$size","$sin","$slice","$split","$sqrt","$stdDevPop","$stdDevSamp","$strcasecmp","$strLenBytes","$strLenCP","$substr","$substrBytes","$substrCP","$subtract","$sum","$switch","$tan","$toBool","$toDate","$toDecimal","$toDouble","$toInt","$toLong","$toObjectId","$toString","$toLower","$toUpper","$trim","$trunc","$type","$week","$year","$zip","$count","$dateAdd","$dateDiff","$dateSubtract","$dateTrunc","$getField","$rand","$sampleRate","$setField","$unsetField","$comment","$explain","$hint","$max","$maxTimeMS","$min","$orderby","$query","$returnKey","$showDiskLoc","$natural"],t="(?:"+($=$.map((function(e){return e.replace("$","\\$")}))).join("|")+")\\b";e.languages.mongodb=e.languages.extend("javascript",{}),e.languages.insertBefore("mongodb","string",{property:{pattern:/(?:(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1|(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)(?=\s*:)/,greedy:!0,inside:{keyword:RegExp("^(['\"])?"+t+"(?:\\1)?$")}}}),e.languages.mongodb.string.inside={url:{pattern:/https?:\/\/[-\w@:%.+~#=]{1,256}\.[a-z0-9()]{1,6}\b[-\w()@:%+.~#?&/=]*/i,greedy:!0},entity:{pattern:/\b(?:(?:[01]?\d\d?|2[0-4]\d|25[0-5])\.){3}(?:[01]?\d\d?|2[0-4]\d|25[0-5])\b/,greedy:!0}},e.languages.insertBefore("mongodb","constant",{builtin:{pattern:RegExp("\\b(?:"+["ObjectId","Code","BinData","DBRef","Timestamp","NumberLong","NumberDecimal","MaxKey","MinKey","RegExp","ISODate","UUID"].join("|")+")\\b"),alias:"keyword"}})}(e)}e.exports=$,$.displayName="mongodb",$.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5418.00d0c5d1.chunk.js b/ydb/core/viewer/monitoring/static/js/5418.00d0c5d1.chunk.js deleted file mode 100644 index ca1401843730..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5418.00d0c5d1.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5418],{15418:function(e,t,_){e.exports=function(e){"use strict";function t(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=t(e),d={name:"da",weekdays:"s\xf8ndag_mandag_tirsdag_onsdag_torsdag_fredag_l\xf8rdag".split("_"),weekdaysShort:"s\xf8n._man._tirs._ons._tors._fre._l\xf8r.".split("_"),weekdaysMin:"s\xf8._ma._ti._on._to._fr._l\xf8.".split("_"),months:"januar_februar_marts_april_maj_juni_juli_august_september_oktober_november_december".split("_"),monthsShort:"jan._feb._mar._apr._maj_juni_juli_aug._sept._okt._nov._dec.".split("_"),weekStart:1,ordinal:function(e){return e+"."},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY HH:mm",LLLL:"dddd [d.] D. MMMM YYYY [kl.] HH:mm"},relativeTime:{future:"om %s",past:"%s siden",s:"f\xe5 sekunder",m:"et minut",mm:"%d minutter",h:"en time",hh:"%d timer",d:"en dag",dd:"%d dage",M:"en m\xe5ned",MM:"%d m\xe5neder",y:"et \xe5r",yy:"%d \xe5r"}};return _.default.locale(d,null,!0),d}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5438.179dc201.chunk.js b/ydb/core/viewer/monitoring/static/js/5438.179dc201.chunk.js deleted file mode 100644 index 9375ad80c74e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5438.179dc201.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5438],{45438:(e,a,r)=>{r.r(a),r.d(a,{ConnectToDBSyntaxHighlighter:()=>x});var n=r(22680),t=r(96873),o=r(96298),l=r(80719),g=r(81571),c=r(46306),s=r(1431),i=r(56421),d=r(29866),p=r(30249),u=r(81243),b=r(62422),y=r(77506),h=r(8300),A=r(63636),m=r(60712);o.A.registerLanguage("bash",l.A),o.A.registerLanguage("cpp",g.A),o.A.registerLanguage("csharp",c.A),o.A.registerLanguage("go",s.A),o.A.registerLanguage("java",i.A),o.A.registerLanguage("javascript",d.A),o.A.registerLanguage("php",p.A),o.A.registerLanguage("python",u.A);const w={...h.XT,'pre[class*="language-"]':{...h.XT['pre[class*="language-"]'],background:b.A['pre[class*="language-"]'].background,scrollbarColor:"var(--g-color-scroll-handle) transparent"},'code[class*="language-"]':{...h.XT['code[class*="language-"]'],whiteSpace:"pre"}},k={...h.BB,'pre[class*="language-"]':{...h.BB['pre[class*="language-"]'],background:"var(--g-color-base-misc-light)",scrollbarColor:"var(--g-color-scroll-handle) transparent"},'code[class*="language-"]':{...h.BB['code[class*="language-"]'],whiteSpace:"pre"}},v=(0,y.cn)("ydb-connect-to-db-syntax-highlighter");function x({text:e,language:a}){const r=(0,n.i)(),l="dark"===r||"dark-hc"===r;return(0,m.jsxs)("div",{className:v("wrapper"),children:[(0,m.jsx)("div",{className:v("sticky-container"),children:(0,m.jsx)(t.b,{view:"flat-secondary",size:"s",className:v("copy"),text:e,children:(0,A.A)("copy")})}),(0,m.jsx)(o.A,{language:a,style:l?w:k,customStyle:{height:"100%"},children:e})]})}},8300:(e,a,r)=>{r.d(a,{BB:()=>l,TL:()=>c,XT:()=>g});var n=r(43733),t=r(32138),o=r(62422);const l={...t.A,'pre[class*="language-"]':{...t.A['pre[class*="language-"]'],background:"transparent",margin:0},'code[class*="language-"]':{...t.A['code[class*="language-"]'],background:"transparent",color:"var(--g-color-text-primary)",whiteSpace:"pre-wrap"},comment:{color:"#969896"},string:{color:"#a31515"},tablepath:{color:"#338186"},function:{color:"#7a3e9d"},udf:{color:"#7a3e9d"},type:{color:"#4d932d"},boolean:{color:"#608b4e"},constant:{color:"#608b4e"},variable:{color:"#001188"}},g={...o.A,'pre[class*="language-"]':{...o.A['pre[class*="language-"]'],background:"transparent",margin:0},'code[class*="language-"]':{...o.A['code[class*="language-"]'],background:"transparent",color:"var(--g-color-text-primary)",whiteSpace:"pre-wrap"},comment:{color:"#969896"},string:{color:"#ce9178"},tablepath:{color:"#338186"},function:{color:"#9e7bb0"},udf:{color:"#9e7bb0"},type:{color:"#6A8759"},boolean:{color:"#608b4e"},constant:{color:"#608b4e"},variable:{color:"#74b0df"}};function c(e){e.languages.yql={comment:[{pattern:/--.*$/m,greedy:!0},{pattern:/\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0}],tablepath:{pattern:/(`[\w/]+`\s*\.\s*)?`[^`]+`/,greedy:!0},string:[{pattern:/'(?:\\[\s\S]|[^\\'])*'/,greedy:!0},{pattern:/"(?:\\[\s\S]|[^\\"])*"/,greedy:!0},{pattern:/@@(?:[^@]|@(?!@))*@@/,greedy:!0}],variable:[{pattern:/\$[a-zA-Z_]\w*/,greedy:!0}],function:{pattern:new RegExp(`\\b(?:${n.XB.join("|")})\\b`,"i"),greedy:!0},keyword:{pattern:new RegExp(`\\b(?:${n.RE.join("|")})\\b`,"i"),greedy:!0},udf:{pattern:/[A-Za-z_]\w*::[A-Za-z_]\w*/,greedy:!0},type:{pattern:new RegExp(`\\b(?:${n.to.join("|")})\\b`,"i"),greedy:!0},boolean:{pattern:/\b(?:true|false|null)\b/i,greedy:!0},number:{pattern:/[+-]?(?:\d+(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?/i,greedy:!0},operator:{pattern:/[-+*/%<>!=&|^~]+|\b(?:and|or|not|is|like|ilike|rlike|in|between)\b/i,greedy:!0},punctuation:{pattern:/[;[\](){}.,]/,greedy:!0}}}c.displayName="yql",c.aliases=["yql"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/54520.c2776d7f.chunk.js b/ydb/core/viewer/monitoring/static/js/54520.c2776d7f.chunk.js new file mode 100644 index 000000000000..396ca6ed5ed6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/54520.c2776d7f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[54520],{54520:(e,t,i)=>{i.d(t,{default:()=>s});var a=i(93425);const s=i.n(a)()},93425:e=>{function t(e){e.languages.solidity=e.languages.extend("clike",{"class-name":{pattern:/(\b(?:contract|enum|interface|library|new|struct|using)\s+)(?!\d)[\w$]+/,lookbehind:!0},keyword:/\b(?:_|anonymous|as|assembly|assert|break|calldata|case|constant|constructor|continue|contract|default|delete|do|else|emit|enum|event|external|for|from|function|if|import|indexed|inherited|interface|internal|is|let|library|mapping|memory|modifier|new|payable|pragma|private|public|pure|require|returns?|revert|selfdestruct|solidity|storage|struct|suicide|switch|this|throw|using|var|view|while)\b/,operator:/=>|->|:=|=:|\*\*|\+\+|--|\|\||&&|<<=?|>>=?|[-+*/%^&|<>!=]=?|[~?]/}),e.languages.insertBefore("solidity","keyword",{builtin:/\b(?:address|bool|byte|u?int(?:8|16|24|32|40|48|56|64|72|80|88|96|104|112|120|128|136|144|152|160|168|176|184|192|200|208|216|224|232|240|248|256)?|string|bytes(?:[1-9]|[12]\d|3[0-2])?)\b/}),e.languages.insertBefore("solidity","number",{version:{pattern:/([<>]=?|\^)\d+\.\d+\.\d+\b/,lookbehind:!0,alias:"number"}}),e.languages.sol=e.languages.solidity}e.exports=t,t.displayName="solidity",t.aliases=["sol"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5453.921caa82.chunk.js b/ydb/core/viewer/monitoring/static/js/5453.921caa82.chunk.js deleted file mode 100644 index 84230b0ccfe1..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5453.921caa82.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5453],{25453:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"mk",weekdays:"\u043d\u0435\u0434\u0435\u043b\u0430_\u043f\u043e\u043d\u0435\u0434\u0435\u043b\u043d\u0438\u043a_\u0432\u0442\u043e\u0440\u043d\u0438\u043a_\u0441\u0440\u0435\u0434\u0430_\u0447\u0435\u0442\u0432\u0440\u0442\u043e\u043a_\u043f\u0435\u0442\u043e\u043a_\u0441\u0430\u0431\u043e\u0442\u0430".split("_"),months:"\u0458\u0430\u043d\u0443\u0430\u0440\u0438_\u0444\u0435\u0432\u0440\u0443\u0430\u0440\u0438_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0438\u043b_\u043c\u0430\u0458_\u0458\u0443\u043d\u0438_\u0458\u0443\u043b\u0438_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043f\u0442\u0435\u043c\u0432\u0440\u0438_\u043e\u043a\u0442\u043e\u043c\u0432\u0440\u0438_\u043d\u043e\u0435\u043c\u0432\u0440\u0438_\u0434\u0435\u043a\u0435\u043c\u0432\u0440\u0438".split("_"),weekStart:1,weekdaysShort:"\u043d\u0435\u0434_\u043f\u043e\u043d_\u0432\u0442\u043e_\u0441\u0440\u0435_\u0447\u0435\u0442_\u043f\u0435\u0442_\u0441\u0430\u0431".split("_"),monthsShort:"\u0458\u0430\u043d_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0458_\u0458\u0443\u043d_\u0458\u0443\u043b_\u0430\u0432\u0433_\u0441\u0435\u043f_\u043e\u043a\u0442_\u043d\u043e\u0435_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u043de_\u043fo_\u0432\u0442_\u0441\u0440_\u0447\u0435_\u043f\u0435_\u0441a".split("_"),ordinal:function(_){return _},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"D.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY H:mm",LLLL:"dddd, D MMMM YYYY H:mm"},relativeTime:{future:"\u043f\u043e\u0441\u043b\u0435 %s",past:"\u043f\u0440\u0435\u0434 %s",s:"\u043d\u0435\u043a\u043e\u043b\u043a\u0443 \u0441\u0435\u043a\u0443\u043d\u0434\u0438",m:"\u043c\u0438\u043d\u0443\u0442\u0430",mm:"%d \u043c\u0438\u043d\u0443\u0442\u0438",h:"\u0447\u0430\u0441",hh:"%d \u0447\u0430\u0441\u0430",d:"\u0434\u0435\u043d",dd:"%d \u0434\u0435\u043d\u0430",M:"\u043c\u0435\u0441\u0435\u0446",MM:"%d \u043c\u0435\u0441\u0435\u0446\u0438",y:"\u0433\u043e\u0434\u0438\u043d\u0430",yy:"%d \u0433\u043e\u0434\u0438\u043d\u0438"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5454.e8f64f1a.chunk.js b/ydb/core/viewer/monitoring/static/js/5454.e8f64f1a.chunk.js deleted file mode 100644 index c1ac2b455bed..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5454.e8f64f1a.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5454.e8f64f1a.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5454],{55454:(t,e,r)=>{r.r(e),r.d(e,{conf:()=>s,language:()=>o});var s={brackets:[],autoClosingPairs:[],surroundingPairs:[]},o={keywords:[],typeKeywords:[],tokenPostfix:".csp",operators:[],symbols:/[=>{function s(e){e.languages.pcaxis={string:/"[^"]*"/,keyword:{pattern:/((?:^|;)\s*)[-A-Z\d]+(?:\s*\[[-\w]+\])?(?:\s*\("[^"]*"(?:,\s*"[^"]*")*\))?(?=\s*=)/,lookbehind:!0,greedy:!0,inside:{keyword:/^[-A-Z\d]+/,language:{pattern:/^(\s*)\[[-\w]+\]/,lookbehind:!0,inside:{punctuation:/^\[|\]$/,property:/[-\w]+/}},"sub-key":{pattern:/^(\s*)\S[\s\S]*/,lookbehind:!0,inside:{parameter:{pattern:/"[^"]*"/,alias:"property"},punctuation:/^\(|\)$|,/}}}},operator:/=/,tlist:{pattern:/TLIST\s*\(\s*\w+(?:(?:\s*,\s*"[^"]*")+|\s*,\s*"[^"]*"-"[^"]*")?\s*\)/,greedy:!0,inside:{function:/^TLIST/,property:{pattern:/^(\s*\(\s*)\w+/,lookbehind:!0},string:/"[^"]*"/,punctuation:/[(),]/,operator:/-/}},punctuation:/[;,]/,number:{pattern:/(^|\s)\d+(?:\.\d+)?(?!\S)/,lookbehind:!0},boolean:/NO|YES/},e.languages.px=e.languages.pcaxis}e.exports=s,s.displayName="pcaxis",s.aliases=["px"]},54597:(e,s,n)=>{n.d(s,{default:()=>t});var a=n(45488);const t=n.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/54651.40344b3d.chunk.js b/ydb/core/viewer/monitoring/static/js/54651.40344b3d.chunk.js new file mode 100644 index 000000000000..2215df275767 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/54651.40344b3d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[54651],{54651:(a,t,e)=>{e.d(t,{default:()=>n});var o=e(61618);const n=e.n(o)()},61618:a=>{function t(a){a.languages.roboconf={comment:/#.*/,keyword:{pattern:/(^|\s)(?:(?:external|import)\b|(?:facet|instance of)(?=[ \t]+[\w-]+[ \t]*\{))/,lookbehind:!0},component:{pattern:/[\w-]+(?=[ \t]*\{)/,alias:"variable"},property:/[\w.-]+(?=[ \t]*:)/,value:{pattern:/(=[ \t]*(?![ \t]))[^,;]+/,lookbehind:!0,alias:"attr-value"},optional:{pattern:/\(optional\)/,alias:"builtin"},wildcard:{pattern:/(\.)\*/,lookbehind:!0,alias:"operator"},punctuation:/[{},.;:=]/}}a.exports=t,t.displayName="roboconf",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/54678.5a7b7b35.chunk.js b/ydb/core/viewer/monitoring/static/js/54678.5a7b7b35.chunk.js new file mode 100644 index 000000000000..4f79f8d4dd52 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/54678.5a7b7b35.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 54678.5a7b7b35.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[54678],{54678:(e,n,s)=>{s.r(n),s.d(n,{conf:()=>i,language:()=>o});var i={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},o={defaultToken:"",tokenPostfix:".ini",escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[[/^\[[^\]]*\]/,"metatag"],[/(^\w+)(\s*)(\=)/,["key","","delimiter"]],{include:"@whitespace"},[/\d+/,"number"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/"/,"string",'@string."'],[/'/,"string","@string.'"]],whitespace:[[/[ \t\r\n]+/,""],[/^\s*[#;].*$/,"comment"]],string:[[/[^\\"']+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/["']/,{cases:{"$#==$S2":{token:"string",next:"@pop"},"@default":"string"}}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5542.7c13d444.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/54678.5a7b7b35.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5542.7c13d444.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/54678.5a7b7b35.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/54781.9ee0aecd.chunk.js b/ydb/core/viewer/monitoring/static/js/54781.9ee0aecd.chunk.js new file mode 100644 index 000000000000..77fa9c2334e6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/54781.9ee0aecd.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[54781],{54781:(e,t,n)=>{n.d(t,{default:()=>i});var a=n(76466);const i=n.n(a)()},76466:e=>{function t(e){!function(e){e.languages.pug={comment:{pattern:/(^([\t ]*))\/\/.*(?:(?:\r?\n|\r)\2[\t ].+)*/m,lookbehind:!0},"multiline-script":{pattern:/(^([\t ]*)script\b.*\.[\t ]*)(?:(?:\r?\n|\r(?!\n))(?:\2[\t ].+|\s*?(?=\r?\n|\r)))+/m,lookbehind:!0,inside:e.languages.javascript},filter:{pattern:/(^([\t ]*)):.+(?:(?:\r?\n|\r(?!\n))(?:\2[\t ].+|\s*?(?=\r?\n|\r)))+/m,lookbehind:!0,inside:{"filter-name":{pattern:/^:[\w-]+/,alias:"variable"},text:/\S[\s\S]*/}},"multiline-plain-text":{pattern:/(^([\t ]*)[\w\-#.]+\.[\t ]*)(?:(?:\r?\n|\r(?!\n))(?:\2[\t ].+|\s*?(?=\r?\n|\r)))+/m,lookbehind:!0},markup:{pattern:/(^[\t ]*)<.+/m,lookbehind:!0,inside:e.languages.markup},doctype:{pattern:/((?:^|\n)[\t ]*)doctype(?: .+)?/,lookbehind:!0},"flow-control":{pattern:/(^[\t ]*)(?:case|default|each|else|if|unless|when|while)\b(?: .+)?/m,lookbehind:!0,inside:{each:{pattern:/^each .+? in\b/,inside:{keyword:/\b(?:each|in)\b/,punctuation:/,/}},branch:{pattern:/^(?:case|default|else|if|unless|when|while)\b/,alias:"keyword"},rest:e.languages.javascript}},keyword:{pattern:/(^[\t ]*)(?:append|block|extends|include|prepend)\b.+/m,lookbehind:!0},mixin:[{pattern:/(^[\t ]*)mixin .+/m,lookbehind:!0,inside:{keyword:/^mixin/,function:/\w+(?=\s*\(|\s*$)/,punctuation:/[(),.]/}},{pattern:/(^[\t ]*)\+.+/m,lookbehind:!0,inside:{name:{pattern:/^\+\w+/,alias:"function"},rest:e.languages.javascript}}],script:{pattern:/(^[\t ]*script(?:(?:&[^(]+)?\([^)]+\))*[\t ]).+/m,lookbehind:!0,inside:e.languages.javascript},"plain-text":{pattern:/(^[\t ]*(?!-)[\w\-#.]*[\w\-](?:(?:&[^(]+)?\([^)]+\))*\/?[\t ]).+/m,lookbehind:!0},tag:{pattern:/(^[\t ]*)(?!-)[\w\-#.]*[\w\-](?:(?:&[^(]+)?\([^)]+\))*\/?:?/m,lookbehind:!0,inside:{attributes:[{pattern:/&[^(]+\([^)]+\)/,inside:e.languages.javascript},{pattern:/\([^)]+\)/,inside:{"attr-value":{pattern:/(=\s*(?!\s))(?:\{[^}]*\}|[^,)\r\n]+)/,lookbehind:!0,inside:e.languages.javascript},"attr-name":/[\w-]+(?=\s*!?=|\s*[,)])/,punctuation:/[!=(),]+/}}],punctuation:/:/,"attr-id":/#[\w\-]+/,"attr-class":/\.[\w\-]+/}},code:[{pattern:/(^[\t ]*(?:-|!?=)).+/m,lookbehind:!0,inside:e.languages.javascript}],punctuation:/[.\-!=|]+/};for(var t=/(^([\t ]*)):(?:(?:\r?\n|\r(?!\n))(?:\2[\t ].+|\s*?(?=\r?\n|\r)))+/.source,n=[{filter:"atpl",language:"twig"},{filter:"coffee",language:"coffeescript"},"ejs","handlebars","less","livescript","markdown",{filter:"sass",language:"scss"},"stylus"],a={},i=0,r=n.length;i",(function(){return s.filter})),"m"),lookbehind:!0,inside:{"filter-name":{pattern:/^:[\w-]+/,alias:"variable"},text:{pattern:/\S[\s\S]*/,alias:[s.language,"language-"+s.language],inside:e.languages[s.language]}}})}e.languages.insertBefore("pug","filter",a)}(e)}e.exports=t,t.displayName="pug",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/54861.f927c937.chunk.js b/ydb/core/viewer/monitoring/static/js/54861.f927c937.chunk.js new file mode 100644 index 000000000000..6f33626f45ae --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/54861.f927c937.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[54861],{5314:e=>{function a(e){e.languages["excel-formula"]={comment:{pattern:/(\bN\(\s*)"(?:[^"]|"")*"(?=\s*\))/i,lookbehind:!0,greedy:!0},string:{pattern:/"(?:[^"]|"")*"(?!")/,greedy:!0},reference:{pattern:/(?:'[^']*'|(?:[^\s()[\]{}<>*?"';,$&]*\[[^^\s()[\]{}<>*?"']+\])?\w+)!/,greedy:!0,alias:"string",inside:{operator:/!$/,punctuation:/'/,sheet:{pattern:/[^[\]]+$/,alias:"function"},file:{pattern:/\[[^[\]]+\]$/,inside:{punctuation:/[[\]]/}},path:/[\s\S]+/}},"function-name":{pattern:/\b[A-Z]\w*(?=\()/i,alias:"keyword"},range:{pattern:/\$?\b(?:[A-Z]+\$?\d+:\$?[A-Z]+\$?\d+|[A-Z]+:\$?[A-Z]+|\d+:\$?\d+)\b/i,alias:"property",inside:{operator:/:/,cell:/\$?[A-Z]+\$?\d+/i,column:/\$?[A-Z]+/i,row:/\$?\d+/}},cell:{pattern:/\b[A-Z]+\d+\b|\$[A-Za-z]+\$?\d+\b|\b[A-Za-z]+\$\d+\b/,alias:"property"},number:/(?:\b\d+(?:\.\d+)?|\B\.\d+)(?:e[+-]?\d+)?\b/i,boolean:/\b(?:FALSE|TRUE)\b/i,operator:/[-+*/^%=&,]|<[=>]?|>=?/,punctuation:/[[\]();{}|]/},e.languages.xlsx=e.languages.xls=e.languages["excel-formula"]}e.exports=a,a.displayName="excelFormula",a.aliases=[]},54861:(e,a,n)=>{n.d(a,{default:()=>i});var t=n(5314);const i=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5530.da339b78.chunk.js b/ydb/core/viewer/monitoring/static/js/5530.da339b78.chunk.js new file mode 100644 index 000000000000..23a16bef23be --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/5530.da339b78.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5530],{5530:(e,s,a)=>{a.d(s,{default:()=>t});var n=a(79031);const t=a.n(n)()},79031:e=>{function s(e){e.languages.processing=e.languages.extend("clike",{keyword:/\b(?:break|case|catch|class|continue|default|else|extends|final|for|if|implements|import|new|null|private|public|return|static|super|switch|this|try|void|while)\b/,function:/\b\w+(?=\s*\()/,operator:/<[<=]?|>[>=]?|&&?|\|\|?|[%?]|[!=+\-*\/]=?/}),e.languages.insertBefore("processing","number",{constant:/\b(?!XML\b)[A-Z][A-Z\d_]+\b/,type:{pattern:/\b(?:boolean|byte|char|color|double|float|int|[A-Z]\w*)\b/,alias:"class-name"}})}e.exports=s,s.displayName="processing",s.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5542.7c13d444.chunk.js b/ydb/core/viewer/monitoring/static/js/5542.7c13d444.chunk.js deleted file mode 100644 index 15c4e16ac876..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5542.7c13d444.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5542.7c13d444.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5542],{15542:(e,t,a)=>{a.r(t),a.d(t,{conf:()=>n,language:()=>i});var n={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["[","]"],["(",")"],["{","}"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment","identifier"]},{open:"[",close:"]",notIn:["string","comment","identifier"]},{open:"(",close:")",notIn:["string","comment","identifier"]},{open:"{",close:"}",notIn:["string","comment","identifier"]}]},i={defaultToken:"",tokenPostfix:".pq",ignoreCase:!1,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"{",close:"}",token:"delimiter.brackets"},{open:"(",close:")",token:"delimiter.parenthesis"}],operatorKeywords:["and","not","or"],keywords:["as","each","else","error","false","if","in","is","let","meta","otherwise","section","shared","then","true","try","type"],constructors:["#binary","#date","#datetime","#datetimezone","#duration","#table","#time"],constants:["#infinity","#nan","#sections","#shared"],typeKeywords:["action","any","anynonnull","none","null","logical","number","time","date","datetime","datetimezone","duration","text","binary","list","record","table","function"],builtinFunctions:["Access.Database","Action.Return","Action.Sequence","Action.Try","ActiveDirectory.Domains","AdoDotNet.DataSource","AdoDotNet.Query","AdobeAnalytics.Cubes","AnalysisServices.Database","AnalysisServices.Databases","AzureStorage.BlobContents","AzureStorage.Blobs","AzureStorage.Tables","Binary.Buffer","Binary.Combine","Binary.Compress","Binary.Decompress","Binary.End","Binary.From","Binary.FromList","Binary.FromText","Binary.InferContentType","Binary.Length","Binary.ToList","Binary.ToText","BinaryFormat.7BitEncodedSignedInteger","BinaryFormat.7BitEncodedUnsignedInteger","BinaryFormat.Binary","BinaryFormat.Byte","BinaryFormat.ByteOrder","BinaryFormat.Choice","BinaryFormat.Decimal","BinaryFormat.Double","BinaryFormat.Group","BinaryFormat.Length","BinaryFormat.List","BinaryFormat.Null","BinaryFormat.Record","BinaryFormat.SignedInteger16","BinaryFormat.SignedInteger32","BinaryFormat.SignedInteger64","BinaryFormat.Single","BinaryFormat.Text","BinaryFormat.Transform","BinaryFormat.UnsignedInteger16","BinaryFormat.UnsignedInteger32","BinaryFormat.UnsignedInteger64","Byte.From","Character.FromNumber","Character.ToNumber","Combiner.CombineTextByDelimiter","Combiner.CombineTextByEachDelimiter","Combiner.CombineTextByLengths","Combiner.CombineTextByPositions","Combiner.CombineTextByRanges","Comparer.Equals","Comparer.FromCulture","Comparer.Ordinal","Comparer.OrdinalIgnoreCase","Csv.Document","Cube.AddAndExpandDimensionColumn","Cube.AddMeasureColumn","Cube.ApplyParameter","Cube.AttributeMemberId","Cube.AttributeMemberProperty","Cube.CollapseAndRemoveColumns","Cube.Dimensions","Cube.DisplayFolders","Cube.Measures","Cube.Parameters","Cube.Properties","Cube.PropertyKey","Cube.ReplaceDimensions","Cube.Transform","Currency.From","DB2.Database","Date.AddDays","Date.AddMonths","Date.AddQuarters","Date.AddWeeks","Date.AddYears","Date.Day","Date.DayOfWeek","Date.DayOfWeekName","Date.DayOfYear","Date.DaysInMonth","Date.EndOfDay","Date.EndOfMonth","Date.EndOfQuarter","Date.EndOfWeek","Date.EndOfYear","Date.From","Date.FromText","Date.IsInCurrentDay","Date.IsInCurrentMonth","Date.IsInCurrentQuarter","Date.IsInCurrentWeek","Date.IsInCurrentYear","Date.IsInNextDay","Date.IsInNextMonth","Date.IsInNextNDays","Date.IsInNextNMonths","Date.IsInNextNQuarters","Date.IsInNextNWeeks","Date.IsInNextNYears","Date.IsInNextQuarter","Date.IsInNextWeek","Date.IsInNextYear","Date.IsInPreviousDay","Date.IsInPreviousMonth","Date.IsInPreviousNDays","Date.IsInPreviousNMonths","Date.IsInPreviousNQuarters","Date.IsInPreviousNWeeks","Date.IsInPreviousNYears","Date.IsInPreviousQuarter","Date.IsInPreviousWeek","Date.IsInPreviousYear","Date.IsInYearToDate","Date.IsLeapYear","Date.Month","Date.MonthName","Date.QuarterOfYear","Date.StartOfDay","Date.StartOfMonth","Date.StartOfQuarter","Date.StartOfWeek","Date.StartOfYear","Date.ToRecord","Date.ToText","Date.WeekOfMonth","Date.WeekOfYear","Date.Year","DateTime.AddZone","DateTime.Date","DateTime.FixedLocalNow","DateTime.From","DateTime.FromFileTime","DateTime.FromText","DateTime.IsInCurrentHour","DateTime.IsInCurrentMinute","DateTime.IsInCurrentSecond","DateTime.IsInNextHour","DateTime.IsInNextMinute","DateTime.IsInNextNHours","DateTime.IsInNextNMinutes","DateTime.IsInNextNSeconds","DateTime.IsInNextSecond","DateTime.IsInPreviousHour","DateTime.IsInPreviousMinute","DateTime.IsInPreviousNHours","DateTime.IsInPreviousNMinutes","DateTime.IsInPreviousNSeconds","DateTime.IsInPreviousSecond","DateTime.LocalNow","DateTime.Time","DateTime.ToRecord","DateTime.ToText","DateTimeZone.FixedLocalNow","DateTimeZone.FixedUtcNow","DateTimeZone.From","DateTimeZone.FromFileTime","DateTimeZone.FromText","DateTimeZone.LocalNow","DateTimeZone.RemoveZone","DateTimeZone.SwitchZone","DateTimeZone.ToLocal","DateTimeZone.ToRecord","DateTimeZone.ToText","DateTimeZone.ToUtc","DateTimeZone.UtcNow","DateTimeZone.ZoneHours","DateTimeZone.ZoneMinutes","Decimal.From","Diagnostics.ActivityId","Diagnostics.Trace","DirectQueryCapabilities.From","Double.From","Duration.Days","Duration.From","Duration.FromText","Duration.Hours","Duration.Minutes","Duration.Seconds","Duration.ToRecord","Duration.ToText","Duration.TotalDays","Duration.TotalHours","Duration.TotalMinutes","Duration.TotalSeconds","Embedded.Value","Error.Record","Excel.CurrentWorkbook","Excel.Workbook","Exchange.Contents","Expression.Constant","Expression.Evaluate","Expression.Identifier","Facebook.Graph","File.Contents","Folder.Contents","Folder.Files","Function.From","Function.Invoke","Function.InvokeAfter","Function.IsDataSource","GoogleAnalytics.Accounts","Guid.From","HdInsight.Containers","HdInsight.Contents","HdInsight.Files","Hdfs.Contents","Hdfs.Files","Informix.Database","Int16.From","Int32.From","Int64.From","Int8.From","ItemExpression.From","Json.Document","Json.FromValue","Lines.FromBinary","Lines.FromText","Lines.ToBinary","Lines.ToText","List.Accumulate","List.AllTrue","List.Alternate","List.AnyTrue","List.Average","List.Buffer","List.Combine","List.Contains","List.ContainsAll","List.ContainsAny","List.Count","List.Covariance","List.DateTimeZones","List.DateTimes","List.Dates","List.Difference","List.Distinct","List.Durations","List.FindText","List.First","List.FirstN","List.Generate","List.InsertRange","List.Intersect","List.IsDistinct","List.IsEmpty","List.Last","List.LastN","List.MatchesAll","List.MatchesAny","List.Max","List.MaxN","List.Median","List.Min","List.MinN","List.Mode","List.Modes","List.NonNullCount","List.Numbers","List.PositionOf","List.PositionOfAny","List.Positions","List.Product","List.Random","List.Range","List.RemoveFirstN","List.RemoveItems","List.RemoveLastN","List.RemoveMatchingItems","List.RemoveNulls","List.RemoveRange","List.Repeat","List.ReplaceMatchingItems","List.ReplaceRange","List.ReplaceValue","List.Reverse","List.Select","List.Single","List.SingleOrDefault","List.Skip","List.Sort","List.StandardDeviation","List.Sum","List.Times","List.Transform","List.TransformMany","List.Union","List.Zip","Logical.From","Logical.FromText","Logical.ToText","MQ.Queue","MySQL.Database","Number.Abs","Number.Acos","Number.Asin","Number.Atan","Number.Atan2","Number.BitwiseAnd","Number.BitwiseNot","Number.BitwiseOr","Number.BitwiseShiftLeft","Number.BitwiseShiftRight","Number.BitwiseXor","Number.Combinations","Number.Cos","Number.Cosh","Number.Exp","Number.Factorial","Number.From","Number.FromText","Number.IntegerDivide","Number.IsEven","Number.IsNaN","Number.IsOdd","Number.Ln","Number.Log","Number.Log10","Number.Mod","Number.Permutations","Number.Power","Number.Random","Number.RandomBetween","Number.Round","Number.RoundAwayFromZero","Number.RoundDown","Number.RoundTowardZero","Number.RoundUp","Number.Sign","Number.Sin","Number.Sinh","Number.Sqrt","Number.Tan","Number.Tanh","Number.ToText","OData.Feed","Odbc.DataSource","Odbc.Query","OleDb.DataSource","OleDb.Query","Oracle.Database","Percentage.From","PostgreSQL.Database","RData.FromBinary","Record.AddField","Record.Combine","Record.Field","Record.FieldCount","Record.FieldNames","Record.FieldOrDefault","Record.FieldValues","Record.FromList","Record.FromTable","Record.HasFields","Record.RemoveFields","Record.RenameFields","Record.ReorderFields","Record.SelectFields","Record.ToList","Record.ToTable","Record.TransformFields","Replacer.ReplaceText","Replacer.ReplaceValue","RowExpression.Column","RowExpression.From","Salesforce.Data","Salesforce.Reports","SapBusinessWarehouse.Cubes","SapHana.Database","SharePoint.Contents","SharePoint.Files","SharePoint.Tables","Single.From","Soda.Feed","Splitter.SplitByNothing","Splitter.SplitTextByAnyDelimiter","Splitter.SplitTextByDelimiter","Splitter.SplitTextByEachDelimiter","Splitter.SplitTextByLengths","Splitter.SplitTextByPositions","Splitter.SplitTextByRanges","Splitter.SplitTextByRepeatedLengths","Splitter.SplitTextByWhitespace","Sql.Database","Sql.Databases","SqlExpression.SchemaFrom","SqlExpression.ToExpression","Sybase.Database","Table.AddColumn","Table.AddIndexColumn","Table.AddJoinColumn","Table.AddKey","Table.AggregateTableColumn","Table.AlternateRows","Table.Buffer","Table.Column","Table.ColumnCount","Table.ColumnNames","Table.ColumnsOfType","Table.Combine","Table.CombineColumns","Table.Contains","Table.ContainsAll","Table.ContainsAny","Table.DemoteHeaders","Table.Distinct","Table.DuplicateColumn","Table.ExpandListColumn","Table.ExpandRecordColumn","Table.ExpandTableColumn","Table.FillDown","Table.FillUp","Table.FilterWithDataTable","Table.FindText","Table.First","Table.FirstN","Table.FirstValue","Table.FromColumns","Table.FromList","Table.FromPartitions","Table.FromRecords","Table.FromRows","Table.FromValue","Table.Group","Table.HasColumns","Table.InsertRows","Table.IsDistinct","Table.IsEmpty","Table.Join","Table.Keys","Table.Last","Table.LastN","Table.MatchesAllRows","Table.MatchesAnyRows","Table.Max","Table.MaxN","Table.Min","Table.MinN","Table.NestedJoin","Table.Partition","Table.PartitionValues","Table.Pivot","Table.PositionOf","Table.PositionOfAny","Table.PrefixColumns","Table.Profile","Table.PromoteHeaders","Table.Range","Table.RemoveColumns","Table.RemoveFirstN","Table.RemoveLastN","Table.RemoveMatchingRows","Table.RemoveRows","Table.RemoveRowsWithErrors","Table.RenameColumns","Table.ReorderColumns","Table.Repeat","Table.ReplaceErrorValues","Table.ReplaceKeys","Table.ReplaceMatchingRows","Table.ReplaceRelationshipIdentity","Table.ReplaceRows","Table.ReplaceValue","Table.ReverseRows","Table.RowCount","Table.Schema","Table.SelectColumns","Table.SelectRows","Table.SelectRowsWithErrors","Table.SingleRow","Table.Skip","Table.Sort","Table.SplitColumn","Table.ToColumns","Table.ToList","Table.ToRecords","Table.ToRows","Table.TransformColumnNames","Table.TransformColumnTypes","Table.TransformColumns","Table.TransformRows","Table.Transpose","Table.Unpivot","Table.UnpivotOtherColumns","Table.View","Table.ViewFunction","TableAction.DeleteRows","TableAction.InsertRows","TableAction.UpdateRows","Tables.GetRelationships","Teradata.Database","Text.AfterDelimiter","Text.At","Text.BeforeDelimiter","Text.BetweenDelimiters","Text.Clean","Text.Combine","Text.Contains","Text.End","Text.EndsWith","Text.Format","Text.From","Text.FromBinary","Text.Insert","Text.Length","Text.Lower","Text.Middle","Text.NewGuid","Text.PadEnd","Text.PadStart","Text.PositionOf","Text.PositionOfAny","Text.Proper","Text.Range","Text.Remove","Text.RemoveRange","Text.Repeat","Text.Replace","Text.ReplaceRange","Text.Select","Text.Split","Text.SplitAny","Text.Start","Text.StartsWith","Text.ToBinary","Text.ToList","Text.Trim","Text.TrimEnd","Text.TrimStart","Text.Upper","Time.EndOfHour","Time.From","Time.FromText","Time.Hour","Time.Minute","Time.Second","Time.StartOfHour","Time.ToRecord","Time.ToText","Type.AddTableKey","Type.ClosedRecord","Type.Facets","Type.ForFunction","Type.ForRecord","Type.FunctionParameters","Type.FunctionRequiredParameters","Type.FunctionReturn","Type.Is","Type.IsNullable","Type.IsOpenRecord","Type.ListItem","Type.NonNullable","Type.OpenRecord","Type.RecordFields","Type.ReplaceFacets","Type.ReplaceTableKeys","Type.TableColumn","Type.TableKeys","Type.TableRow","Type.TableSchema","Type.Union","Uri.BuildQueryString","Uri.Combine","Uri.EscapeDataString","Uri.Parts","Value.Add","Value.As","Value.Compare","Value.Divide","Value.Equals","Value.Firewall","Value.FromText","Value.Is","Value.Metadata","Value.Multiply","Value.NativeQuery","Value.NullableEquals","Value.RemoveMetadata","Value.ReplaceMetadata","Value.ReplaceType","Value.Subtract","Value.Type","ValueAction.NativeStatement","ValueAction.Replace","Variable.Value","Web.Contents","Web.Page","WebAction.Request","Xml.Document","Xml.Tables"],builtinConstants:["BinaryEncoding.Base64","BinaryEncoding.Hex","BinaryOccurrence.Optional","BinaryOccurrence.Repeating","BinaryOccurrence.Required","ByteOrder.BigEndian","ByteOrder.LittleEndian","Compression.Deflate","Compression.GZip","CsvStyle.QuoteAfterDelimiter","CsvStyle.QuoteAlways","Culture.Current","Day.Friday","Day.Monday","Day.Saturday","Day.Sunday","Day.Thursday","Day.Tuesday","Day.Wednesday","ExtraValues.Error","ExtraValues.Ignore","ExtraValues.List","GroupKind.Global","GroupKind.Local","JoinAlgorithm.Dynamic","JoinAlgorithm.LeftHash","JoinAlgorithm.LeftIndex","JoinAlgorithm.PairwiseHash","JoinAlgorithm.RightHash","JoinAlgorithm.RightIndex","JoinAlgorithm.SortMerge","JoinKind.FullOuter","JoinKind.Inner","JoinKind.LeftAnti","JoinKind.LeftOuter","JoinKind.RightAnti","JoinKind.RightOuter","JoinSide.Left","JoinSide.Right","MissingField.Error","MissingField.Ignore","MissingField.UseNull","Number.E","Number.Epsilon","Number.NaN","Number.NegativeInfinity","Number.PI","Number.PositiveInfinity","Occurrence.All","Occurrence.First","Occurrence.Last","Occurrence.Optional","Occurrence.Repeating","Occurrence.Required","Order.Ascending","Order.Descending","Precision.Decimal","Precision.Double","QuoteStyle.Csv","QuoteStyle.None","RelativePosition.FromEnd","RelativePosition.FromStart","RoundingMode.AwayFromZero","RoundingMode.Down","RoundingMode.ToEven","RoundingMode.TowardZero","RoundingMode.Up","SapHanaDistribution.All","SapHanaDistribution.Connection","SapHanaDistribution.Off","SapHanaDistribution.Statement","SapHanaRangeOperator.Equals","SapHanaRangeOperator.GreaterThan","SapHanaRangeOperator.GreaterThanOrEquals","SapHanaRangeOperator.LessThan","SapHanaRangeOperator.LessThanOrEquals","SapHanaRangeOperator.NotEquals","TextEncoding.Ascii","TextEncoding.BigEndianUnicode","TextEncoding.Unicode","TextEncoding.Utf16","TextEncoding.Utf8","TextEncoding.Windows","TraceLevel.Critical","TraceLevel.Error","TraceLevel.Information","TraceLevel.Verbose","TraceLevel.Warning","WebMethod.Delete","WebMethod.Get","WebMethod.Head","WebMethod.Patch","WebMethod.Post","WebMethod.Put"],builtinTypes:["Action.Type","Any.Type","Binary.Type","BinaryEncoding.Type","BinaryOccurrence.Type","Byte.Type","ByteOrder.Type","Character.Type","Compression.Type","CsvStyle.Type","Currency.Type","Date.Type","DateTime.Type","DateTimeZone.Type","Day.Type","Decimal.Type","Double.Type","Duration.Type","ExtraValues.Type","Function.Type","GroupKind.Type","Guid.Type","Int16.Type","Int32.Type","Int64.Type","Int8.Type","JoinAlgorithm.Type","JoinKind.Type","JoinSide.Type","List.Type","Logical.Type","MissingField.Type","None.Type","Null.Type","Number.Type","Occurrence.Type","Order.Type","Password.Type","Percentage.Type","Precision.Type","QuoteStyle.Type","Record.Type","RelativePosition.Type","RoundingMode.Type","SapHanaDistribution.Type","SapHanaRangeOperator.Type","Single.Type","Table.Type","Text.Type","TextEncoding.Type","Time.Type","TraceLevel.Type","Type.Type","Uri.Type","WebMethod.Type"],tokenizer:{root:[[/#"[\w \.]+"/,"identifier.quote"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/\d+([eE][\-+]?\d+)?/,"number"],[/(#?[a-z]+)\b/,{cases:{"@typeKeywords":"type","@keywords":"keyword","@constants":"constant","@constructors":"constructor","@operatorKeywords":"operators","@default":"identifier"}}],[/\b([A-Z][a-zA-Z0-9]+\.Type)\b/,{cases:{"@builtinTypes":"type","@default":"identifier"}}],[/\b([A-Z][a-zA-Z0-9]+\.[A-Z][a-zA-Z0-9]+)\b/,{cases:{"@builtinFunctions":"keyword.function","@builtinConstants":"constant","@default":"identifier"}}],[/\b([a-zA-Z_][\w\.]*)\b/,"identifier"],{include:"@whitespace"},{include:"@comments"},{include:"@strings"},[/[{}()\[\]]/,"@brackets"],[/([=\+<>\-\*&@\?\/!])|([<>]=)|(<>)|(=>)|(\.\.\.)|(\.\.)/,"operators"],[/[,;]/,"delimiter"]],whitespace:[[/\s+/,"white"]],comments:[["\\/\\*","comment","@comment"],["\\/\\/+.*","comment"]],comment:[["\\*\\/","comment","@pop"],[".","comment"]],strings:[['"',"string","@string"]],string:[['""',"string.escape"],['"',"string","@pop"],[".","string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/55454.4f52583e.chunk.js b/ydb/core/viewer/monitoring/static/js/55454.4f52583e.chunk.js new file mode 100644 index 000000000000..f9c165dd1b2e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/55454.4f52583e.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 55454.4f52583e.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[55454],{55454:(t,e,r)=>{r.r(e),r.d(e,{conf:()=>s,language:()=>o});var s={brackets:[],autoClosingPairs:[],surroundingPairs:[]},o={keywords:[],typeKeywords:[],tokenPostfix:".csp",operators:[],symbols:/[=>{function n(e){!function(e){e.languages.tremor={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|(?:--|\/\/|#).*)/,lookbehind:!0},"interpolated-string":null,extractor:{pattern:/\b[a-z_]\w*\|(?:[^\r\n\\|]|\\(?:\r\n|[\s\S]))*\|/i,greedy:!0,inside:{regex:{pattern:/(^re)\|[\s\S]+/,lookbehind:!0},function:/^\w+/,value:/\|[\s\S]+/}},identifier:{pattern:/`[^`]*`/,greedy:!0},function:/\b[a-z_]\w*(?=\s*(?:::\s*<|\())\b/,keyword:/\b(?:args|as|by|case|config|connect|connector|const|copy|create|default|define|deploy|drop|each|emit|end|erase|event|flow|fn|for|from|group|having|insert|into|intrinsic|let|links|match|merge|mod|move|of|operator|patch|pipeline|recur|script|select|set|sliding|state|stream|to|tumbling|update|use|when|where|window|with)\b/,boolean:/\b(?:false|null|true)\b/i,number:/\b(?:0b[01_]*|0x[0-9a-fA-F_]*|\d[\d_]*(?:\.\d[\d_]*)?(?:[Ee][+-]?[\d_]+)?)\b/,"pattern-punctuation":{pattern:/%(?=[({[])/,alias:"punctuation"},operator:/[-+*\/%~!^]=?|=[=>]?|&[&=]?|\|[|=]?|<>?>?=?|(?:absent|and|not|or|present|xor)\b/,punctuation:/::|[;\[\]()\{\},.:]/};var n=/#\{(?:[^"{}]|\{[^{}]*\}|"(?:[^"\\\r\n]|\\(?:\r\n|[\s\S]))*")*\}/.source;e.languages.tremor["interpolated-string"]={pattern:RegExp(/(^|[^\\])/.source+'(?:"""(?:'+/[^"\\#]|\\[\s\S]|"(?!"")|#(?!\{)/.source+"|"+n+')*"""|"(?:'+/[^"\\\r\n#]|\\(?:\r\n|[\s\S])|#(?!\{)/.source+"|"+n+')*")'),lookbehind:!0,greedy:!0,inside:{interpolation:{pattern:RegExp(n),inside:{punctuation:/^#\{|\}$/,expression:{pattern:/[\s\S]+/,inside:e.languages.tremor}}},string:/[\s\S]+/}},e.languages.troy=e.languages.tremor,e.languages.trickle=e.languages.tremor}(e)}e.exports=n,n.displayName="tremor",n.aliases=[]},55528:(e,n,t)=>{t.d(n,{default:()=>a});var r=t(54817);const a=t.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/55534.43828e20.chunk.js b/ydb/core/viewer/monitoring/static/js/55534.43828e20.chunk.js new file mode 100644 index 000000000000..ef20dba1a6ec --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/55534.43828e20.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[55534],{8063:(e,s,a)=>{var n=a(90323);function r(e){e.register(n),e.languages.aspnet=e.languages.extend("markup",{"page-directive":{pattern:/<%\s*@.*%>/,alias:"tag",inside:{"page-directive":{pattern:/<%\s*@\s*(?:Assembly|Control|Implements|Import|Master(?:Type)?|OutputCache|Page|PreviousPageType|Reference|Register)?|%>/i,alias:"tag"},rest:e.languages.markup.tag.inside}},directive:{pattern:/<%.*%>/,alias:"tag",inside:{directive:{pattern:/<%\s*?[$=%#:]{0,2}|%>/,alias:"tag"},rest:e.languages.csharp}}}),e.languages.aspnet.tag.pattern=/<(?!%)\/?[^\s>\/]+(?:\s+[^\s>\/=]+(?:=(?:("|')(?:\\[\s\S]|(?!\1)[^\\])*\1|[^\s'">=]+))?)*\s*\/?>/,e.languages.insertBefore("inside","punctuation",{directive:e.languages.aspnet.directive},e.languages.aspnet.tag.inside["attr-value"]),e.languages.insertBefore("aspnet","comment",{"asp-comment":{pattern:/<%--[\s\S]*?--%>/,alias:["asp","comment"]}}),e.languages.insertBefore("aspnet",e.languages.javascript?"script":"tag",{"asp-script":{pattern:/(]*>)[\s\S]*?(?=<\/script>)/i,lookbehind:!0,alias:["asp","script"],inside:e.languages.csharp||{}}})}e.exports=r,r.displayName="aspnet",r.aliases=[]},55534:(e,s,a)=>{a.d(s,{default:()=>r});var n=a(8063);const r=a.n(n)()},90323:e=>{function s(e){!function(e){function s(e,s){return e.replace(/<<(\d+)>>/g,(function(e,a){return"(?:"+s[+a]+")"}))}function a(e,a,n){return RegExp(s(e,a),n||"")}function n(e,s){for(var a=0;a>/g,(function(){return"(?:"+e+")"}));return e.replace(/<>/g,"[^\\s\\S]")}var r="bool byte char decimal double dynamic float int long object sbyte short string uint ulong ushort var void",t="class enum interface record struct",i="add alias and ascending async await by descending from(?=\\s*(?:\\w|$)) get global group into init(?=\\s*;) join let nameof not notnull on or orderby partial remove select set unmanaged value when where with(?=\\s*{)",o="abstract as base break case catch checked const continue default delegate do else event explicit extern finally fixed for foreach goto if implicit in internal is lock namespace new null operator out override params private protected public readonly ref return sealed sizeof stackalloc static switch this throw try typeof unchecked unsafe using virtual volatile while yield";function c(e){return"\\b(?:"+e.trim().replace(/ /g,"|")+")\\b"}var u=c(t),l=RegExp(c(r+" "+t+" "+i+" "+o)),p=c(t+" "+i+" "+o),d=c(r+" "+t+" "+o),g=n(/<(?:[^<>;=+\-*/%&|^]|<>)*>/.source,2),b=n(/\((?:[^()]|<>)*\)/.source,2),h=/@?\b[A-Za-z_]\w*\b/.source,f=s(/<<0>>(?:\s*<<1>>)?/.source,[h,g]),m=s(/(?!<<0>>)<<1>>(?:\s*\.\s*<<1>>)*/.source,[p,f]),k=/\[\s*(?:,\s*)*\]/.source,y=s(/<<0>>(?:\s*(?:\?\s*)?<<1>>)*(?:\s*\?)?/.source,[m,k]),v=s(/[^,()<>[\];=+\-*/%&|^]|<<0>>|<<1>>|<<2>>/.source,[g,b,k]),w=s(/\(<<0>>+(?:,<<0>>+)+\)/.source,[v]),x=s(/(?:<<0>>|<<1>>)(?:\s*(?:\?\s*)?<<2>>)*(?:\s*\?)?/.source,[w,m,k]),_={keyword:l,punctuation:/[<>()?,.:[\]]/},$=/'(?:[^\r\n'\\]|\\.|\\[Uux][\da-fA-F]{1,8})'/.source,B=/"(?:\\.|[^\\"\r\n])*"/.source,R=/@"(?:""|\\[\s\S]|[^\\"])*"(?!")/.source;e.languages.csharp=e.languages.extend("clike",{string:[{pattern:a(/(^|[^$\\])<<0>>/.source,[R]),lookbehind:!0,greedy:!0},{pattern:a(/(^|[^@$\\])<<0>>/.source,[B]),lookbehind:!0,greedy:!0}],"class-name":[{pattern:a(/(\busing\s+static\s+)<<0>>(?=\s*;)/.source,[m]),lookbehind:!0,inside:_},{pattern:a(/(\busing\s+<<0>>\s*=\s*)<<1>>(?=\s*;)/.source,[h,x]),lookbehind:!0,inside:_},{pattern:a(/(\busing\s+)<<0>>(?=\s*=)/.source,[h]),lookbehind:!0},{pattern:a(/(\b<<0>>\s+)<<1>>/.source,[u,f]),lookbehind:!0,inside:_},{pattern:a(/(\bcatch\s*\(\s*)<<0>>/.source,[m]),lookbehind:!0,inside:_},{pattern:a(/(\bwhere\s+)<<0>>/.source,[h]),lookbehind:!0},{pattern:a(/(\b(?:is(?:\s+not)?|as)\s+)<<0>>/.source,[y]),lookbehind:!0,inside:_},{pattern:a(/\b<<0>>(?=\s+(?!<<1>>|with\s*\{)<<2>>(?:\s*[=,;:{)\]]|\s+(?:in|when)\b))/.source,[x,d,h]),inside:_}],keyword:l,number:/(?:\b0(?:x[\da-f_]*[\da-f]|b[01_]*[01])|(?:\B\.\d+(?:_+\d+)*|\b\d+(?:_+\d+)*(?:\.\d+(?:_+\d+)*)?)(?:e[-+]?\d+(?:_+\d+)*)?)(?:[dflmu]|lu|ul)?\b/i,operator:/>>=?|<<=?|[-=]>|([-+&|])\1|~|\?\?=?|[-+*/%&|^!=<>]=?/,punctuation:/\?\.?|::|[{}[\];(),.:]/}),e.languages.insertBefore("csharp","number",{range:{pattern:/\.\./,alias:"operator"}}),e.languages.insertBefore("csharp","punctuation",{"named-parameter":{pattern:a(/([(,]\s*)<<0>>(?=\s*:)/.source,[h]),lookbehind:!0,alias:"punctuation"}}),e.languages.insertBefore("csharp","class-name",{namespace:{pattern:a(/(\b(?:namespace|using)\s+)<<0>>(?:\s*\.\s*<<0>>)*(?=\s*[;{])/.source,[h]),lookbehind:!0,inside:{punctuation:/\./}},"type-expression":{pattern:a(/(\b(?:default|sizeof|typeof)\s*\(\s*(?!\s))(?:[^()\s]|\s(?!\s)|<<0>>)*(?=\s*\))/.source,[b]),lookbehind:!0,alias:"class-name",inside:_},"return-type":{pattern:a(/<<0>>(?=\s+(?:<<1>>\s*(?:=>|[({]|\.\s*this\s*\[)|this\s*\[))/.source,[x,m]),inside:_,alias:"class-name"},"constructor-invocation":{pattern:a(/(\bnew\s+)<<0>>(?=\s*[[({])/.source,[x]),lookbehind:!0,inside:_,alias:"class-name"},"generic-method":{pattern:a(/<<0>>\s*<<1>>(?=\s*\()/.source,[h,g]),inside:{function:a(/^<<0>>/.source,[h]),generic:{pattern:RegExp(g),alias:"class-name",inside:_}}},"type-list":{pattern:a(/\b((?:<<0>>\s+<<1>>|record\s+<<1>>\s*<<5>>|where\s+<<2>>)\s*:\s*)(?:<<3>>|<<4>>|<<1>>\s*<<5>>|<<6>>)(?:\s*,\s*(?:<<3>>|<<4>>|<<6>>))*(?=\s*(?:where|[{;]|=>|$))/.source,[u,f,h,x,l.source,b,/\bnew\s*\(\s*\)/.source]),lookbehind:!0,inside:{"record-arguments":{pattern:a(/(^(?!new\s*\()<<0>>\s*)<<1>>/.source,[f,b]),lookbehind:!0,greedy:!0,inside:e.languages.csharp},keyword:l,"class-name":{pattern:RegExp(x),greedy:!0,inside:_},punctuation:/[,()]/}},preprocessor:{pattern:/(^[\t ]*)#.*/m,lookbehind:!0,alias:"property",inside:{directive:{pattern:/(#)\b(?:define|elif|else|endif|endregion|error|if|line|nullable|pragma|region|undef|warning)\b/,lookbehind:!0,alias:"keyword"}}}});var S=B+"|"+$,E=s(/\/(?![*/])|\/\/[^\r\n]*[\r\n]|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>/.source,[S]),C=n(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[E]),2),T=/\b(?:assembly|event|field|method|module|param|property|return|type)\b/.source,j=s(/<<0>>(?:\s*\(<<1>>*\))?/.source,[m,C]);e.languages.insertBefore("csharp","class-name",{attribute:{pattern:a(/((?:^|[^\s\w>)?])\s*\[\s*)(?:<<0>>\s*:\s*)?<<1>>(?:\s*,\s*<<1>>)*(?=\s*\])/.source,[T,j]),lookbehind:!0,greedy:!0,inside:{target:{pattern:a(/^<<0>>(?=\s*:)/.source,[T]),alias:"keyword"},"attribute-arguments":{pattern:a(/\(<<0>>*\)/.source,[C]),inside:e.languages.csharp},"class-name":{pattern:RegExp(m),inside:{punctuation:/\./}},punctuation:/[:,]/}}});var z=/:[^}\r\n]+/.source,A=n(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[E]),2),P=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[A,z]),I=n(s(/[^"'/()]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>|\(<>*\)/.source,[S]),2),N=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[I,z]);function F(s,n){return{interpolation:{pattern:a(/((?:^|[^{])(?:\{\{)*)<<0>>/.source,[s]),lookbehind:!0,inside:{"format-string":{pattern:a(/(^\{(?:(?![}:])<<0>>)*)<<1>>(?=\}$)/.source,[n,z]),lookbehind:!0,inside:{punctuation:/^:/}},punctuation:/^\{|\}$/,expression:{pattern:/[\s\S]+/,alias:"language-csharp",inside:e.languages.csharp}}},string:/[\s\S]+/}}e.languages.insertBefore("csharp","string",{"interpolation-string":[{pattern:a(/(^|[^\\])(?:\$@|@\$)"(?:""|\\[\s\S]|\{\{|<<0>>|[^\\{"])*"/.source,[P]),lookbehind:!0,greedy:!0,inside:F(P,A)},{pattern:a(/(^|[^@\\])\$"(?:\\.|\{\{|<<0>>|[^\\"{])*"/.source,[N]),lookbehind:!0,greedy:!0,inside:F(N,I)}],char:{pattern:RegExp($),greedy:!0}}),e.languages.dotnet=e.languages.cs=e.languages.csharp}(e)}e.exports=s,s.displayName="csharp",s.aliases=["dotnet","cs"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/55651.bd57c77c.chunk.js b/ydb/core/viewer/monitoring/static/js/55651.bd57c77c.chunk.js new file mode 100644 index 000000000000..29ddcb90fac3 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/55651.bd57c77c.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[55651],{55651:(e,n,r)=>{r.d(n,{default:()=>a});var t=r(63270);const a=r.n(t)()},63270:e=>{function n(e){!function(e){var n={pattern:/(\b\d+)(?:%|[a-z]+)/,lookbehind:!0},r={pattern:/(^|[^\w.-])-?(?:\d+(?:\.\d+)?|\.\d+)/,lookbehind:!0},t={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|\/\/.*)/,lookbehind:!0},url:{pattern:/\burl\((["']?).*?\1\)/i,greedy:!0},string:{pattern:/("|')(?:(?!\1)[^\\\r\n]|\\(?:\r\n|[\s\S]))*\1/,greedy:!0},interpolation:null,func:null,important:/\B!(?:important|optional)\b/i,keyword:{pattern:/(^|\s+)(?:(?:else|for|if|return|unless)(?=\s|$)|@[\w-]+)/,lookbehind:!0},hexcode:/#[\da-f]{3,6}/i,color:[/\b(?:AliceBlue|AntiqueWhite|Aqua|Aquamarine|Azure|Beige|Bisque|Black|BlanchedAlmond|Blue|BlueViolet|Brown|BurlyWood|CadetBlue|Chartreuse|Chocolate|Coral|CornflowerBlue|Cornsilk|Crimson|Cyan|DarkBlue|DarkCyan|DarkGoldenRod|DarkGr[ae]y|DarkGreen|DarkKhaki|DarkMagenta|DarkOliveGreen|DarkOrange|DarkOrchid|DarkRed|DarkSalmon|DarkSeaGreen|DarkSlateBlue|DarkSlateGr[ae]y|DarkTurquoise|DarkViolet|DeepPink|DeepSkyBlue|DimGr[ae]y|DodgerBlue|FireBrick|FloralWhite|ForestGreen|Fuchsia|Gainsboro|GhostWhite|Gold|GoldenRod|Gr[ae]y|Green|GreenYellow|HoneyDew|HotPink|IndianRed|Indigo|Ivory|Khaki|Lavender|LavenderBlush|LawnGreen|LemonChiffon|LightBlue|LightCoral|LightCyan|LightGoldenRodYellow|LightGr[ae]y|LightGreen|LightPink|LightSalmon|LightSeaGreen|LightSkyBlue|LightSlateGr[ae]y|LightSteelBlue|LightYellow|Lime|LimeGreen|Linen|Magenta|Maroon|MediumAquaMarine|MediumBlue|MediumOrchid|MediumPurple|MediumSeaGreen|MediumSlateBlue|MediumSpringGreen|MediumTurquoise|MediumVioletRed|MidnightBlue|MintCream|MistyRose|Moccasin|NavajoWhite|Navy|OldLace|Olive|OliveDrab|Orange|OrangeRed|Orchid|PaleGoldenRod|PaleGreen|PaleTurquoise|PaleVioletRed|PapayaWhip|PeachPuff|Peru|Pink|Plum|PowderBlue|Purple|Red|RosyBrown|RoyalBlue|SaddleBrown|Salmon|SandyBrown|SeaGreen|SeaShell|Sienna|Silver|SkyBlue|SlateBlue|SlateGr[ae]y|Snow|SpringGreen|SteelBlue|Tan|Teal|Thistle|Tomato|Transparent|Turquoise|Violet|Wheat|White|WhiteSmoke|Yellow|YellowGreen)\b/i,{pattern:/\b(?:hsl|rgb)\(\s*\d{1,3}\s*,\s*\d{1,3}%?\s*,\s*\d{1,3}%?\s*\)\B|\b(?:hsl|rgb)a\(\s*\d{1,3}\s*,\s*\d{1,3}%?\s*,\s*\d{1,3}%?\s*,\s*(?:0|0?\.\d+|1)\s*\)\B/i,inside:{unit:n,number:r,function:/[\w-]+(?=\()/,punctuation:/[(),]/}}],entity:/\\[\da-f]{1,8}/i,unit:n,boolean:/\b(?:false|true)\b/,operator:[/~|[+!\/%<>?=]=?|[-:]=|\*[*=]?|\.{2,3}|&&|\|\||\B-\B|\b(?:and|in|is(?: a| defined| not|nt)?|not|or)\b/],number:r,punctuation:/[{}()\[\];:,]/};t.interpolation={pattern:/\{[^\r\n}:]+\}/,alias:"variable",inside:{delimiter:{pattern:/^\{|\}$/,alias:"punctuation"},rest:t}},t.func={pattern:/[\w-]+\([^)]*\).*/,inside:{function:/^[^(]+/,rest:t}},e.languages.stylus={"atrule-declaration":{pattern:/(^[ \t]*)@.+/m,lookbehind:!0,inside:{atrule:/^@[\w-]+/,rest:t}},"variable-declaration":{pattern:/(^[ \t]*)[\w$-]+\s*.?=[ \t]*(?:\{[^{}]*\}|\S.*|$)/m,lookbehind:!0,inside:{variable:/^\S+/,rest:t}},statement:{pattern:/(^[ \t]*)(?:else|for|if|return|unless)[ \t].+/m,lookbehind:!0,inside:{keyword:/^\S+/,rest:t}},"property-declaration":{pattern:/((?:^|\{)([ \t]*))(?:[\w-]|\{[^}\r\n]+\})+(?:\s*:\s*|[ \t]+)(?!\s)[^{\r\n]*(?:;|[^{\r\n,]$(?!(?:\r?\n|\r)(?:\{|\2[ \t])))/m,lookbehind:!0,inside:{property:{pattern:/^[^\s:]+/,inside:{interpolation:t.interpolation}},rest:t}},selector:{pattern:/(^[ \t]*)(?:(?=\S)(?:[^{}\r\n:()]|::?[\w-]+(?:\([^)\r\n]*\)|(?![\w-]))|\{[^}\r\n]+\})+)(?:(?:\r?\n|\r)(?:\1(?:(?=\S)(?:[^{}\r\n:()]|::?[\w-]+(?:\([^)\r\n]*\)|(?![\w-]))|\{[^}\r\n]+\})+)))*(?:,$|\{|(?=(?:\r?\n|\r)(?:\{|\1[ \t])))/m,lookbehind:!0,inside:{interpolation:t.interpolation,comment:t.comment,punctuation:/[{},]/}},func:t.func,string:t.string,comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|\/\/.*)/,lookbehind:!0,greedy:!0},interpolation:t.interpolation,punctuation:/[{}()\[\];:.]/}}(e)}e.exports=n,n.displayName="stylus",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5579.a2c9515c.chunk.js b/ydb/core/viewer/monitoring/static/js/5579.a2c9515c.chunk.js deleted file mode 100644 index 55fcc28fd863..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5579.a2c9515c.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5579],{65579:function(_,e,a){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var a=e(_),t={name:"tzl",weekdays:"S\xfaladi_L\xfane\xe7i_Maitzi_M\xe1rcuri_Xh\xfaadi_Vi\xe9ner\xe7i_S\xe1turi".split("_"),months:"Januar_Fevraglh_Mar\xe7_Avr\xefu_Mai_G\xfcn_Julia_Guscht_Setemvar_Listop\xe4ts_Noemvar_Zecemvar".split("_"),weekStart:1,weekdaysShort:"S\xfal_L\xfan_Mai_M\xe1r_Xh\xfa_Vi\xe9_S\xe1t".split("_"),monthsShort:"Jan_Fev_Mar_Avr_Mai_G\xfcn_Jul_Gus_Set_Lis_Noe_Zec".split("_"),weekdaysMin:"S\xfa_L\xfa_Ma_M\xe1_Xh_Vi_S\xe1".split("_"),ordinal:function(_){return _},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD.MM.YYYY",LL:"D. MMMM [dallas] YYYY",LLL:"D. MMMM [dallas] YYYY HH.mm",LLLL:"dddd, [li] D. MMMM [dallas] YYYY HH.mm"}};return a.default.locale(t,null,!0),t}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/55816.ceb201d4.chunk.js b/ydb/core/viewer/monitoring/static/js/55816.ceb201d4.chunk.js new file mode 100644 index 000000000000..f8b9533b32d6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/55816.ceb201d4.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[55816],{55816:function(e,_,n){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var n=_(e),t={name:"tk",weekdays:"\xddek\u015fenbe_Du\u015fenbe_Si\u015fenbe_\xc7ar\u015fenbe_Pen\u015fenbe_Anna_\u015eenbe".split("_"),weekdaysShort:"\xddek_Du\u015f_Si\u015f_\xc7ar_Pen_Ann_\u015een".split("_"),weekdaysMin:"\xddk_D\u015f_S\u015f_\xc7r_Pn_An_\u015en".split("_"),months:"\xddanwar_Fewral_Mart_Aprel_Ma\xfd_I\xfdun_I\xfdul_Awgust_Sent\xfdabr_Okt\xfdabr_No\xfdabr_Dekabr".split("_"),monthsShort:"\xddan_Few_Mar_Apr_Ma\xfd_I\xfdn_I\xfdl_Awg_Sen_Okt_No\xfd_Dek".split("_"),weekStart:1,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s so\u0148",past:"%s \xf6\u0148",s:"birn\xe4\xe7e sekunt",m:"bir minut",mm:"%d minut",h:"bir sagat",hh:"%d sagat",d:"bir g\xfcn",dd:"%d g\xfcn",M:"bir a\xfd",MM:"%d a\xfd",y:"bir \xfdyl",yy:"%d \xfdyl"},ordinal:function(e){return e+"."}};return n.default.locale(t,null,!0),t}(n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/55853.2ca378d0.chunk.js b/ydb/core/viewer/monitoring/static/js/55853.2ca378d0.chunk.js new file mode 100644 index 000000000000..ad8e4860f77e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/55853.2ca378d0.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[55853],{55853:function(s,i,e){s.exports=function(s){"use strict";function i(s){return s&&"object"==typeof s&&"default"in s?s:{default:s}}var e=i(s),M="sausio_vasario_kovo_baland\u017eio_gegu\u017e\u0117s_bir\u017eelio_liepos_rugpj\u016b\u010dio_rugs\u0117jo_spalio_lapkri\u010dio_gruod\u017eio".split("_"),a="sausis_vasaris_kovas_balandis_gegu\u017e\u0117_bir\u017eelis_liepa_rugpj\u016btis_rugs\u0117jis_spalis_lapkritis_gruodis".split("_"),d=/D[oD]?(\[[^\[\]]*\]|\s)+MMMM?|MMMM?(\[[^\[\]]*\]|\s)+D[oD]?/,l=function(s,i){return d.test(i)?M[s.month()]:a[s.month()]};l.s=a,l.f=M;var Y={name:"lt",weekdays:"sekmadienis_pirmadienis_antradienis_tre\u010diadienis_ketvirtadienis_penktadienis_\u0161e\u0161tadienis".split("_"),weekdaysShort:"sek_pir_ant_tre_ket_pen_\u0161e\u0161".split("_"),weekdaysMin:"s_p_a_t_k_pn_\u0161".split("_"),months:l,monthsShort:"sau_vas_kov_bal_geg_bir_lie_rgp_rgs_spa_lap_grd".split("_"),ordinal:function(s){return s+"."},weekStart:1,relativeTime:{future:"u\u017e %s",past:"prie\u0161 %s",s:"kelias sekundes",m:"minut\u0119",mm:"%d minutes",h:"valand\u0105",hh:"%d valandas",d:"dien\u0105",dd:"%d dienas",M:"m\u0117nes\u012f",MM:"%d m\u0117nesius",y:"metus",yy:"%d metus"},format:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY [m.] MMMM D [d.]",LLL:"YYYY [m.] MMMM D [d.], HH:mm [val.]",LLLL:"YYYY [m.] MMMM D [d.], dddd, HH:mm [val.]",l:"YYYY-MM-DD",ll:"YYYY [m.] MMMM D [d.]",lll:"YYYY [m.] MMMM D [d.], HH:mm [val.]",llll:"YYYY [m.] MMMM D [d.], ddd, HH:mm [val.]"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY [m.] MMMM D [d.]",LLL:"YYYY [m.] MMMM D [d.], HH:mm [val.]",LLLL:"YYYY [m.] MMMM D [d.], dddd, HH:mm [val.]",l:"YYYY-MM-DD",ll:"YYYY [m.] MMMM D [d.]",lll:"YYYY [m.] MMMM D [d.], HH:mm [val.]",llll:"YYYY [m.] MMMM D [d.], ddd, HH:mm [val.]"}};return e.default.locale(Y,null,!0),Y}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/55990.c86b7669.chunk.js b/ydb/core/viewer/monitoring/static/js/55990.c86b7669.chunk.js new file mode 100644 index 000000000000..3625e0fba77f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/55990.c86b7669.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[55990],{16027:e=>{function a(e){e.languages.ebnf={comment:/\(\*[\s\S]*?\*\)/,string:{pattern:/"[^"\r\n]*"|'[^'\r\n]*'/,greedy:!0},special:{pattern:/\?[^?\r\n]*\?/,greedy:!0,alias:"class-name"},definition:{pattern:/^([\t ]*)[a-z]\w*(?:[ \t]+[a-z]\w*)*(?=\s*=)/im,lookbehind:!0,alias:["rule","keyword"]},rule:/\b[a-z]\w*(?:[ \t]+[a-z]\w*)*\b/i,punctuation:/\([:/]|[:/]\)|[.,;()[\]{}]/,operator:/[-=|*/!]/}}e.exports=a,a.displayName="ebnf",a.aliases=[]},55990:(e,a,n)=>{n.d(a,{default:()=>i});var t=n(16027);const i=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56026.85d58e2b.chunk.js b/ydb/core/viewer/monitoring/static/js/56026.85d58e2b.chunk.js new file mode 100644 index 000000000000..6cac0dbe42cf --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56026.85d58e2b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56026],{22053:e=>{function t(e){e.languages.jolie=e.languages.extend("clike",{string:{pattern:/(^|[^\\])"(?:\\[\s\S]|[^"\\])*"/,lookbehind:!0,greedy:!0},"class-name":{pattern:/((?:\b(?:as|courier|embed|in|inputPort|outputPort|service)\b|@)[ \t]*)\w+/,lookbehind:!0},keyword:/\b(?:as|cH|comp|concurrent|constants|courier|cset|csets|default|define|else|embed|embedded|execution|exit|extender|for|foreach|forward|from|global|if|import|in|include|init|inputPort|install|instanceof|interface|is_defined|linkIn|linkOut|main|new|nullProcess|outputPort|over|private|provide|public|scope|sequential|service|single|spawn|synchronized|this|throw|throws|type|undef|until|while|with)\b/,function:/\b[a-z_]\w*(?=[ \t]*[@(])/i,number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?l?/i,operator:/-[-=>]?|\+[+=]?|<[<=]?|[>=*!]=?|&&|\|\||[?\/%^@|]/,punctuation:/[()[\]{},;.:]/,builtin:/\b(?:Byte|any|bool|char|double|enum|float|int|length|long|ranges|regex|string|undefined|void)\b/}),e.languages.insertBefore("jolie","keyword",{aggregates:{pattern:/(\bAggregates\s*:\s*)(?:\w+(?:\s+with\s+\w+)?\s*,\s*)*\w+(?:\s+with\s+\w+)?/,lookbehind:!0,inside:{keyword:/\bwith\b/,"class-name":/\w+/,punctuation:/,/}},redirects:{pattern:/(\bRedirects\s*:\s*)(?:\w+\s*=>\s*\w+\s*,\s*)*(?:\w+\s*=>\s*\w+)/,lookbehind:!0,inside:{punctuation:/,/,"class-name":/\w+/,operator:/=>/}},property:{pattern:/\b(?:Aggregates|[Ii]nterfaces|Java|Javascript|Jolie|[Ll]ocation|OneWay|[Pp]rotocol|Redirects|RequestResponse)\b(?=[ \t]*:)/}})}e.exports=t,t.displayName="jolie",t.aliases=[]},56026:(e,t,n)=>{n.d(t,{default:()=>s});var i=n(22053);const s=n.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56054.9d70a2ed.chunk.js b/ydb/core/viewer/monitoring/static/js/56054.9d70a2ed.chunk.js new file mode 100644 index 000000000000..5b01cca3e57b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56054.9d70a2ed.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56054],{55485:a=>{function e(a){!function(a){var e={pattern:/\\[\\(){}[\]^$+*?|.]/,alias:"escape"},n=/\\(?:x[\da-fA-F]{2}|u[\da-fA-F]{4}|u\{[\da-fA-F]+\}|0[0-7]{0,2}|[123][0-7]{2}|c[a-zA-Z]|.)/,t="(?:[^\\\\-]|"+n.source+")",s=RegExp(t+"-"+t),i={pattern:/(<|')[^<>']+(?=[>']$)/,lookbehind:!0,alias:"variable"};a.languages.regex={"char-class":{pattern:/((?:^|[^\\])(?:\\\\)*)\[(?:[^\\\]]|\\[\s\S])*\]/,lookbehind:!0,inside:{"char-class-negation":{pattern:/(^\[)\^/,lookbehind:!0,alias:"operator"},"char-class-punctuation":{pattern:/^\[|\]$/,alias:"punctuation"},range:{pattern:s,inside:{escape:n,"range-punctuation":{pattern:/-/,alias:"operator"}}},"special-escape":e,"char-set":{pattern:/\\[wsd]|\\p\{[^{}]+\}/i,alias:"class-name"},escape:n}},"special-escape":e,"char-set":{pattern:/\.|\\[wsd]|\\p\{[^{}]+\}/i,alias:"class-name"},backreference:[{pattern:/\\(?![123][0-7]{2})[1-9]/,alias:"keyword"},{pattern:/\\k<[^<>']+>/,alias:"keyword",inside:{"group-name":i}}],anchor:{pattern:/[$^]|\\[ABbGZz]/,alias:"function"},escape:n,group:[{pattern:/\((?:\?(?:<[^<>']+>|'[^<>']+'|[>:]|{n.d(e,{default:()=>s});var t=n(55485);const s=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56174.562b7d92.chunk.js b/ydb/core/viewer/monitoring/static/js/56174.562b7d92.chunk.js new file mode 100644 index 000000000000..aca1a1324e14 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56174.562b7d92.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56174],{35901:(e,n,t)=>{var s=t(53950);function a(e){e.register(s),function(e){var n=[/"(?:\\[\s\S]|\$\([^)]+\)|\$(?!\()|`[^`]+`|[^"\\`$])*"/.source,/'[^']*'/.source,/\$'(?:[^'\\]|\\[\s\S])*'/.source,/<<-?\s*(["']?)(\w+)\1\s[\s\S]*?[\r\n]\2/.source].join("|");e.languages["shell-session"]={command:{pattern:RegExp(/^/.source+"(?:"+/[^\s@:$#%*!/\\]+@[^\r\n@:$#%*!/\\]+(?::[^\0-\x1F$#%*?"<>:;|]+)?/.source+"|"+/[/~.][^\0-\x1F$#%*?"<>@:;|]*/.source+")?"+/[$#%](?=\s)/.source+/(?:[^\\\r\n \t'"<$]|[ \t](?:(?!#)|#.*$)|\\(?:[^\r]|\r\n?)|\$(?!')|<(?!<)|<>)+/.source.replace(/<>/g,(function(){return n})),"m"),greedy:!0,inside:{info:{pattern:/^[^#$%]+/,alias:"punctuation",inside:{user:/^[^\s@:$#%*!/\\]+@[^\r\n@:$#%*!/\\]+/,punctuation:/:/,path:/[\s\S]+/}},bash:{pattern:/(^[$#%]\s*)\S[\s\S]*/,lookbehind:!0,alias:"language-bash",inside:e.languages.bash},"shell-symbol":{pattern:/^[$#%]/,alias:"important"}}},output:/.(?:.*(?:[\r\n]|.$))*/},e.languages["sh-session"]=e.languages.shellsession=e.languages["shell-session"]}(e)}e.exports=a,a.displayName="shellSession",a.aliases=[]},53950:e=>{function n(e){!function(e){var n="\\b(?:BASH|BASHOPTS|BASH_ALIASES|BASH_ARGC|BASH_ARGV|BASH_CMDS|BASH_COMPLETION_COMPAT_DIR|BASH_LINENO|BASH_REMATCH|BASH_SOURCE|BASH_VERSINFO|BASH_VERSION|COLORTERM|COLUMNS|COMP_WORDBREAKS|DBUS_SESSION_BUS_ADDRESS|DEFAULTS_PATH|DESKTOP_SESSION|DIRSTACK|DISPLAY|EUID|GDMSESSION|GDM_LANG|GNOME_KEYRING_CONTROL|GNOME_KEYRING_PID|GPG_AGENT_INFO|GROUPS|HISTCONTROL|HISTFILE|HISTFILESIZE|HISTSIZE|HOME|HOSTNAME|HOSTTYPE|IFS|INSTANCE|JOB|LANG|LANGUAGE|LC_ADDRESS|LC_ALL|LC_IDENTIFICATION|LC_MEASUREMENT|LC_MONETARY|LC_NAME|LC_NUMERIC|LC_PAPER|LC_TELEPHONE|LC_TIME|LESSCLOSE|LESSOPEN|LINES|LOGNAME|LS_COLORS|MACHTYPE|MAILCHECK|MANDATORY_PATH|NO_AT_BRIDGE|OLDPWD|OPTERR|OPTIND|ORBIT_SOCKETDIR|OSTYPE|PAPERSIZE|PATH|PIPESTATUS|PPID|PS1|PS2|PS3|PS4|PWD|RANDOM|REPLY|SECONDS|SELINUX_INIT|SESSION|SESSIONTYPE|SESSION_MANAGER|SHELL|SHELLOPTS|SHLVL|SSH_AUTH_SOCK|TERM|UID|UPSTART_EVENTS|UPSTART_INSTANCE|UPSTART_JOB|UPSTART_SESSION|USER|WINDOWID|XAUTHORITY|XDG_CONFIG_DIRS|XDG_CURRENT_DESKTOP|XDG_DATA_DIRS|XDG_GREETER_DATA_DIR|XDG_MENU_PREFIX|XDG_RUNTIME_DIR|XDG_SEAT|XDG_SEAT_PATH|XDG_SESSION_DESKTOP|XDG_SESSION_ID|XDG_SESSION_PATH|XDG_SESSION_TYPE|XDG_VTNR|XMODIFIERS)\\b",t={pattern:/(^(["']?)\w+\2)[ \t]+\S.*/,lookbehind:!0,alias:"punctuation",inside:null},s={bash:t,environment:{pattern:RegExp("\\$"+n),alias:"constant"},variable:[{pattern:/\$?\(\([\s\S]+?\)\)/,greedy:!0,inside:{variable:[{pattern:/(^\$\(\([\s\S]+)\)\)/,lookbehind:!0},/^\$\(\(/],number:/\b0x[\dA-Fa-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee]-?\d+)?/,operator:/--|\+\+|\*\*=?|<<=?|>>=?|&&|\|\||[=!+\-*/%<>^&|]=?|[?~:]/,punctuation:/\(\(?|\)\)?|,|;/}},{pattern:/\$\((?:\([^)]+\)|[^()])+\)|`[^`]+`/,greedy:!0,inside:{variable:/^\$\(|^`|\)$|`$/}},{pattern:/\$\{[^}]+\}/,greedy:!0,inside:{operator:/:[-=?+]?|[!\/]|##?|%%?|\^\^?|,,?/,punctuation:/[\[\]]/,environment:{pattern:RegExp("(\\{)"+n),lookbehind:!0,alias:"constant"}}},/\$(?:\w+|[#?*!@$])/],entity:/\\(?:[abceEfnrtv\\"]|O?[0-7]{1,3}|U[0-9a-fA-F]{8}|u[0-9a-fA-F]{4}|x[0-9a-fA-F]{1,2})/};e.languages.bash={shebang:{pattern:/^#!\s*\/.*/,alias:"important"},comment:{pattern:/(^|[^"{\\$])#.*/,lookbehind:!0},"function-name":[{pattern:/(\bfunction\s+)[\w-]+(?=(?:\s*\(?:\s*\))?\s*\{)/,lookbehind:!0,alias:"function"},{pattern:/\b[\w-]+(?=\s*\(\s*\)\s*\{)/,alias:"function"}],"for-or-select":{pattern:/(\b(?:for|select)\s+)\w+(?=\s+in\s)/,alias:"variable",lookbehind:!0},"assign-left":{pattern:/(^|[\s;|&]|[<>]\()\w+(?=\+?=)/,inside:{environment:{pattern:RegExp("(^|[\\s;|&]|[<>]\\()"+n),lookbehind:!0,alias:"constant"}},alias:"variable",lookbehind:!0},string:[{pattern:/((?:^|[^<])<<-?\s*)(\w+)\s[\s\S]*?(?:\r?\n|\r)\2/,lookbehind:!0,greedy:!0,inside:s},{pattern:/((?:^|[^<])<<-?\s*)(["'])(\w+)\2\s[\s\S]*?(?:\r?\n|\r)\3/,lookbehind:!0,greedy:!0,inside:{bash:t}},{pattern:/(^|[^\\](?:\\\\)*)"(?:\\[\s\S]|\$\([^)]+\)|\$(?!\()|`[^`]+`|[^"\\`$])*"/,lookbehind:!0,greedy:!0,inside:s},{pattern:/(^|[^$\\])'[^']*'/,lookbehind:!0,greedy:!0},{pattern:/\$'(?:[^'\\]|\\[\s\S])*'/,greedy:!0,inside:{entity:s.entity}}],environment:{pattern:RegExp("\\$?"+n),alias:"constant"},variable:s.variable,function:{pattern:/(^|[\s;|&]|[<>]\()(?:add|apropos|apt|apt-cache|apt-get|aptitude|aspell|automysqlbackup|awk|basename|bash|bc|bconsole|bg|bzip2|cal|cat|cfdisk|chgrp|chkconfig|chmod|chown|chroot|cksum|clear|cmp|column|comm|composer|cp|cron|crontab|csplit|curl|cut|date|dc|dd|ddrescue|debootstrap|df|diff|diff3|dig|dir|dircolors|dirname|dirs|dmesg|docker|docker-compose|du|egrep|eject|env|ethtool|expand|expect|expr|fdformat|fdisk|fg|fgrep|file|find|fmt|fold|format|free|fsck|ftp|fuser|gawk|git|gparted|grep|groupadd|groupdel|groupmod|groups|grub-mkconfig|gzip|halt|head|hg|history|host|hostname|htop|iconv|id|ifconfig|ifdown|ifup|import|install|ip|jobs|join|kill|killall|less|link|ln|locate|logname|logrotate|look|lpc|lpr|lprint|lprintd|lprintq|lprm|ls|lsof|lynx|make|man|mc|mdadm|mkconfig|mkdir|mke2fs|mkfifo|mkfs|mkisofs|mknod|mkswap|mmv|more|most|mount|mtools|mtr|mutt|mv|nano|nc|netstat|nice|nl|node|nohup|notify-send|npm|nslookup|op|open|parted|passwd|paste|pathchk|ping|pkill|pnpm|podman|podman-compose|popd|pr|printcap|printenv|ps|pushd|pv|quota|quotacheck|quotactl|ram|rar|rcp|reboot|remsync|rename|renice|rev|rm|rmdir|rpm|rsync|scp|screen|sdiff|sed|sendmail|seq|service|sftp|sh|shellcheck|shuf|shutdown|sleep|slocate|sort|split|ssh|stat|strace|su|sudo|sum|suspend|swapon|sync|tac|tail|tar|tee|time|timeout|top|touch|tr|traceroute|tsort|tty|umount|uname|unexpand|uniq|units|unrar|unshar|unzip|update-grub|uptime|useradd|userdel|usermod|users|uudecode|uuencode|v|vcpkg|vdir|vi|vim|virsh|vmstat|wait|watch|wc|wget|whereis|which|who|whoami|write|xargs|xdg-open|yarn|yes|zenity|zip|zsh|zypper)(?=$|[)\s;|&])/,lookbehind:!0},keyword:{pattern:/(^|[\s;|&]|[<>]\()(?:case|do|done|elif|else|esac|fi|for|function|if|in|select|then|until|while)(?=$|[)\s;|&])/,lookbehind:!0},builtin:{pattern:/(^|[\s;|&]|[<>]\()(?:\.|:|alias|bind|break|builtin|caller|cd|command|continue|declare|echo|enable|eval|exec|exit|export|getopts|hash|help|let|local|logout|mapfile|printf|pwd|read|readarray|readonly|return|set|shift|shopt|source|test|times|trap|type|typeset|ulimit|umask|unalias|unset)(?=$|[)\s;|&])/,lookbehind:!0,alias:"class-name"},boolean:{pattern:/(^|[\s;|&]|[<>]\()(?:false|true)(?=$|[)\s;|&])/,lookbehind:!0},"file-descriptor":{pattern:/\B&\d\b/,alias:"important"},operator:{pattern:/\d?<>|>\||\+=|=[=~]?|!=?|<<[<-]?|[&\d]?>>|\d[<>]&?|[<>][&=]?|&[>&]?|\|[&|]?/,inside:{"file-descriptor":{pattern:/^\d/,alias:"important"}}},punctuation:/\$?\(\(?|\)\)?|\.\.|[{}[\];\\]/,number:{pattern:/(^|\s)(?:[1-9]\d*|0)(?:[.,]\d+)?\b/,lookbehind:!0}},t.inside=e.languages.bash;for(var a=["comment","function-name","for-or-select","assign-left","string","environment","function","keyword","builtin","boolean","file-descriptor","operator","punctuation","number"],o=s.variable[1].inside,i=0;i{t.d(n,{default:()=>a});var s=t(35901);const a=t.n(s)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56358.3a141569.chunk.js b/ydb/core/viewer/monitoring/static/js/56358.3a141569.chunk.js new file mode 100644 index 000000000000..200ab60d4991 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56358.3a141569.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 56358.3a141569.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56358],{56358:(e,t,o)=>{o.r(t),o.d(t,{conf:()=>r,language:()=>n});var r={wordPattern:/(unary_[@~!#%^&*()\-=+\\|:<>\/?]+)|([a-zA-Z_$][\w$]*?_=)|(`[^`]+`)|([a-zA-Z_$][\w$]*)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*//\\s*(?:(?:#?region\\b)|(?:))")}}},n={tokenPostfix:".scala",keywords:["asInstanceOf","catch","class","classOf","def","do","else","extends","finally","for","foreach","forSome","if","import","isInstanceOf","macro","match","new","object","package","return","throw","trait","try","type","until","val","var","while","with","yield","given","enum","then"],softKeywords:["as","export","extension","end","derives","on"],constants:["true","false","null","this","super"],modifiers:["abstract","final","implicit","lazy","override","private","protected","sealed"],softModifiers:["inline","opaque","open","transparent","using"],name:/(?:[a-z_$][\w$]*|`[^`]+`)/,type:/(?:[A-Z][\w$]*)/,symbols:/[=>))/,["@brackets","white","variable"]],[/@name/,{cases:{"@keywords":"keyword","@softKeywords":"keyword","@modifiers":"keyword.modifier","@softModifiers":"keyword.modifier","@constants":{token:"constant",next:"@allowMethod"},"@default":{token:"identifier",next:"@allowMethod"}}}],[/@type/,"type","@allowMethod"],{include:"@whitespace"},[/@[a-zA-Z_$][\w$]*(?:\.[a-zA-Z_$][\w$]*)*/,"annotation"],[/[{(]/,"@brackets"],[/[})]/,"@brackets","@allowMethod"],[/\[/,"operator.square"],[/](?!\s*(?:va[rl]|def|type)\b)/,"operator.square","@allowMethod"],[/]/,"operator.square"],[/([=-]>|<-|>:|<:|:>|<%)(?=[\s\w()[\]{},\."'`])/,"keyword"],[/@symbols/,"operator"],[/[;,\.]/,"delimiter"],[/'[a-zA-Z$][\w$]*(?!')/,"attribute.name"],[/'[^\\']'/,"string","@allowMethod"],[/(')(@escapes)(')/,["string","string.escape",{token:"string",next:"@allowMethod"}]],[/'/,"string.invalid"]],import:[[/;/,"delimiter","@pop"],[/^|$/,"","@pop"],[/[ \t]+/,"white"],[/[\n\r]+/,"white","@pop"],[/\/\*/,"comment","@comment"],[/@name|@type/,"type"],[/[(){}]/,"@brackets"],[/[[\]]/,"operator.square"],[/[\.,]/,"delimiter"]],allowMethod:[[/^|$/,"","@pop"],[/[ \t]+/,"white"],[/[\n\r]+/,"white","@pop"],[/\/\*/,"comment","@comment"],[/(?==>[\s\w([{])/,"keyword","@pop"],[/(@name|@symbols)(?=[ \t]*[[({"'`]|[ \t]+(?:[+-]?\.?\d|\w))/,{cases:{"@keywords":{token:"keyword",next:"@pop"},"->|<-|>:|<:|<%":{token:"keyword",next:"@pop"},"@default":{token:"@rematch",next:"@pop"}}}],["","","@pop"]],comment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@push"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],case:[[/\b_\*/,"key"],[/\b(_|true|false|null|this|super)\b/,"keyword","@allowMethod"],[/\bif\b|=>/,"keyword","@pop"],[/`[^`]+`/,"identifier","@allowMethod"],[/@name/,"variable","@allowMethod"],[/:::?|\||@(?![a-z_$])/,"keyword"],{include:"@root"}],vardef:[[/\b_\*/,"key"],[/\b(_|true|false|null|this|super)\b/,"keyword"],[/@name/,"variable"],[/:::?|\||@(?![a-z_$])/,"keyword"],[/=|:(?!:)/,"operator","@pop"],[/$/,"white","@pop"],{include:"@root"}],string:[[/[^\\"\n\r]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}]],stringt:[[/[^\\"\n\r]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/"/,"string"]],fstring:[[/@escapes/,"string.escape"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/%%/,"string"],[/(%)([\-#+ 0,(])(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","keyword.modifier","number","metatag"]],[/(%)(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","number","metatag"]],[/(%)([\-#+ 0,(])(@fstring_conv)/,["metatag","keyword.modifier","metatag"]],[/(%)(@fstring_conv)/,["metatag","metatag"]],[/./,"string"]],fstringt:[[/@escapes/,"string.escape"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/%%/,"string"],[/(%)([\-#+ 0,(])(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","keyword.modifier","number","metatag"]],[/(%)(\d+|\.\d+|\d+\.\d+)(@fstring_conv)/,["metatag","number","metatag"]],[/(%)([\-#+ 0,(])(@fstring_conv)/,["metatag","keyword.modifier","metatag"]],[/(%)(@fstring_conv)/,["metatag","metatag"]],[/./,"string"]],sstring:[[/@escapes/,"string.escape"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/./,"string"]],sstringt:[[/@escapes/,"string.escape"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/\$\$/,"string"],[/(\$)([a-z_]\w*)/,["operator","identifier"]],[/\$\{/,"operator","@interp"],[/./,"string"]],interp:[[/{/,"operator","@push"],[/}/,"operator","@pop"],{include:"@root"}],rawstring:[[/[^"]/,"string"],[/"/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}]],rawstringt:[[/[^"]/,"string"],[/"(?=""")/,"string"],[/"""/,{token:"string.quote",bracket:"@close",switchTo:"@allowMethod"}],[/"/,"string"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5888.4fa64369.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/56358.3a141569.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5888.4fa64369.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/56358.3a141569.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/5636.da9c4c85.chunk.js b/ydb/core/viewer/monitoring/static/js/5636.da9c4c85.chunk.js deleted file mode 100644 index 29725dfcfab9..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5636.da9c4c85.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5636.da9c4c85.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5636],{25636:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>s});var i={comments:{lineComment:"*"},brackets:[["[","]"],["(",")"]]},s={defaultToken:"invalid",ignoreCase:!0,tokenPostfix:".abap",keywords:["abap-source","abbreviated","abstract","accept","accepting","according","activation","actual","add","add-corresponding","adjacent","after","alias","aliases","align","all","allocate","alpha","analysis","analyzer","and","append","appendage","appending","application","archive","area","arithmetic","as","ascending","aspect","assert","assign","assigned","assigning","association","asynchronous","at","attributes","authority","authority-check","avg","back","background","backup","backward","badi","base","before","begin","between","big","binary","bintohex","bit","black","blank","blanks","blob","block","blocks","blue","bound","boundaries","bounds","boxed","break-point","buffer","by","bypassing","byte","byte-order","call","calling","case","cast","casting","catch","center","centered","chain","chain-input","chain-request","change","changing","channels","character","char-to-hex","check","checkbox","ci_","circular","class","class-coding","class-data","class-events","class-methods","class-pool","cleanup","clear","client","clob","clock","close","coalesce","code","coding","col_background","col_group","col_heading","col_key","col_negative","col_normal","col_positive","col_total","collect","color","column","columns","comment","comments","commit","common","communication","comparing","component","components","compression","compute","concat","concat_with_space","concatenate","cond","condense","condition","connect","connection","constants","context","contexts","continue","control","controls","conv","conversion","convert","copies","copy","corresponding","country","cover","cpi","create","creating","critical","currency","currency_conversion","current","cursor","cursor-selection","customer","customer-function","dangerous","data","database","datainfo","dataset","date","dats_add_days","dats_add_months","dats_days_between","dats_is_valid","daylight","dd/mm/yy","dd/mm/yyyy","ddmmyy","deallocate","decimal_shift","decimals","declarations","deep","default","deferred","define","defining","definition","delete","deleting","demand","department","descending","describe","destination","detail","dialog","directory","disconnect","display","display-mode","distinct","divide","divide-corresponding","division","do","dummy","duplicate","duplicates","duration","during","dynamic","dynpro","edit","editor-call","else","elseif","empty","enabled","enabling","encoding","end","endat","endcase","endcatch","endchain","endclass","enddo","endenhancement","end-enhancement-section","endexec","endform","endfunction","endian","endif","ending","endinterface","end-lines","endloop","endmethod","endmodule","end-of-definition","end-of-editing","end-of-file","end-of-page","end-of-selection","endon","endprovide","endselect","end-test-injection","end-test-seam","endtry","endwhile","endwith","engineering","enhancement","enhancement-point","enhancements","enhancement-section","entries","entry","enum","environment","equiv","errormessage","errors","escaping","event","events","exact","except","exception","exceptions","exception-table","exclude","excluding","exec","execute","exists","exit","exit-command","expand","expanding","expiration","explicit","exponent","export","exporting","extend","extended","extension","extract","fail","fetch","field","field-groups","fields","field-symbol","field-symbols","file","filter","filters","filter-table","final","find","first","first-line","fixed-point","fkeq","fkge","flush","font","for","form","format","forward","found","frame","frames","free","friends","from","function","functionality","function-pool","further","gaps","generate","get","giving","gkeq","gkge","global","grant","green","group","groups","handle","handler","harmless","hashed","having","hdb","header","headers","heading","head-lines","help-id","help-request","hextobin","hide","high","hint","hold","hotspot","icon","id","identification","identifier","ids","if","ignore","ignoring","immediately","implementation","implementations","implemented","implicit","import","importing","in","inactive","incl","include","includes","including","increment","index","index-line","infotypes","inheriting","init","initial","initialization","inner","inout","input","insert","instance","instances","instr","intensified","interface","interface-pool","interfaces","internal","intervals","into","inverse","inverted-date","is","iso","job","join","keep","keeping","kernel","key","keys","keywords","kind","language","last","late","layout","leading","leave","left","left-justified","leftplus","leftspace","legacy","length","let","level","levels","like","line","lines","line-count","linefeed","line-selection","line-size","list","listbox","list-processing","little","llang","load","load-of-program","lob","local","locale","locator","logfile","logical","log-point","long","loop","low","lower","lpad","lpi","ltrim","mail","main","major-id","mapping","margin","mark","mask","match","matchcode","max","maximum","medium","members","memory","mesh","message","message-id","messages","messaging","method","methods","min","minimum","minor-id","mm/dd/yy","mm/dd/yyyy","mmddyy","mode","modif","modifier","modify","module","move","move-corresponding","multiply","multiply-corresponding","name","nametab","native","nested","nesting","new","new-line","new-page","new-section","next","no","no-display","no-extension","no-gap","no-gaps","no-grouping","no-heading","no-scrolling","no-sign","no-title","no-topofpage","no-zero","node","nodes","non-unicode","non-unique","not","null","number","object","objects","obligatory","occurrence","occurrences","occurs","of","off","offset","ole","on","only","open","option","optional","options","or","order","other","others","out","outer","output","output-length","overflow","overlay","pack","package","pad","padding","page","pages","parameter","parameters","parameter-table","part","partially","pattern","percentage","perform","performing","person","pf1","pf10","pf11","pf12","pf13","pf14","pf15","pf2","pf3","pf4","pf5","pf6","pf7","pf8","pf9","pf-status","pink","places","pool","pos_high","pos_low","position","pragmas","precompiled","preferred","preserving","primary","print","print-control","priority","private","procedure","process","program","property","protected","provide","public","push","pushbutton","put","queue-only","quickinfo","radiobutton","raise","raising","range","ranges","read","reader","read-only","receive","received","receiver","receiving","red","redefinition","reduce","reduced","ref","reference","refresh","regex","reject","remote","renaming","replace","replacement","replacing","report","request","requested","reserve","reset","resolution","respecting","responsible","result","results","resumable","resume","retry","return","returncode","returning","returns","right","right-justified","rightplus","rightspace","risk","rmc_communication_failure","rmc_invalid_status","rmc_system_failure","role","rollback","rows","rpad","rtrim","run","sap","sap-spool","saving","scale_preserving","scale_preserving_scientific","scan","scientific","scientific_with_leading_zero","scroll","scroll-boundary","scrolling","search","secondary","seconds","section","select","selection","selections","selection-screen","selection-set","selection-sets","selection-table","select-options","send","separate","separated","set","shared","shift","short","shortdump-id","sign_as_postfix","single","size","skip","skipping","smart","some","sort","sortable","sorted","source","specified","split","spool","spots","sql","sqlscript","stable","stamp","standard","starting","start-of-editing","start-of-selection","state","statement","statements","static","statics","statusinfo","step-loop","stop","structure","structures","style","subkey","submatches","submit","subroutine","subscreen","subtract","subtract-corresponding","suffix","sum","summary","summing","supplied","supply","suppress","switch","switchstates","symbol","syncpoints","syntax","syntax-check","syntax-trace","system-call","system-exceptions","system-exit","tab","tabbed","table","tables","tableview","tabstrip","target","task","tasks","test","testing","test-injection","test-seam","text","textpool","then","throw","time","times","timestamp","timezone","tims_is_valid","title","titlebar","title-lines","to","tokenization","tokens","top-lines","top-of-page","trace-file","trace-table","trailing","transaction","transfer","transformation","translate","transporting","trmac","truncate","truncation","try","tstmp_add_seconds","tstmp_current_utctimestamp","tstmp_is_valid","tstmp_seconds_between","type","type-pool","type-pools","types","uline","unassign","under","unicode","union","unique","unit_conversion","unix","unpack","until","unwind","up","update","upper","user","user-command","using","utf-8","valid","value","value-request","values","vary","varying","verification-message","version","via","view","visible","wait","warning","when","whenever","where","while","width","window","windows","with","with-heading","without","with-title","word","work","write","writer","xml","xsd","yellow","yes","yymmdd","zero","zone","abap_system_timezone","abap_user_timezone","access","action","adabas","adjust_numbers","allow_precision_loss","allowed","amdp","applicationuser","as_geo_json","as400","associations","balance","behavior","breakup","bulk","cds","cds_client","check_before_save","child","clients","corr","corr_spearman","cross","cycles","datn_add_days","datn_add_months","datn_days_between","dats_from_datn","dats_tims_to_tstmp","dats_to_datn","db2","db6","ddl","dense_rank","depth","deterministic","discarding","entities","entity","error","failed","finalize","first_value","fltp_to_dec","following","fractional","full","graph","grouping","hierarchy","hierarchy_ancestors","hierarchy_ancestors_aggregate","hierarchy_descendants","hierarchy_descendants_aggregate","hierarchy_siblings","incremental","indicators","lag","last_value","lead","leaves","like_regexpr","link","locale_sap","lock","locks","many","mapped","matched","measures","median","mssqlnt","multiple","nodetype","ntile","nulls","occurrences_regexpr","one","operations","oracle","orphans","over","parent","parents","partition","pcre","period","pfcg_mapping","preceding","privileged","product","projection","rank","redirected","replace_regexpr","reported","response","responses","root","row","row_number","sap_system_date","save","schema","session","sets","shortdump","siblings","spantree","start","stddev","string_agg","subtotal","sybase","tims_from_timn","tims_to_timn","to_blob","to_clob","total","trace-entry","tstmp_to_dats","tstmp_to_dst","tstmp_to_tims","tstmpl_from_utcl","tstmpl_to_utcl","unbounded","utcl_add_seconds","utcl_current","utcl_seconds_between","uuid","var","verbatim"],builtinFunctions:["abs","acos","asin","atan","bit-set","boolc","boolx","ceil","char_off","charlen","cmax","cmin","concat_lines_of","contains","contains_any_not_of","contains_any_of","cos","cosh","count","count_any_not_of","count_any_of","dbmaxlen","distance","escape","exp","find_any_not_of","find_any_of","find_end","floor","frac","from_mixed","ipow","line_exists","line_index","log","log10","matches","nmax","nmin","numofchar","repeat","rescale","reverse","round","segment","shift_left","shift_right","sign","sin","sinh","sqrt","strlen","substring","substring_after","substring_before","substring_from","substring_to","tan","tanh","to_lower","to_mixed","to_upper","trunc","utclong_add","utclong_current","utclong_diff","xsdbool","xstrlen"],typeKeywords:["b","c","d","decfloat16","decfloat34","f","i","int8","n","p","s","string","t","utclong","x","xstring","any","clike","csequence","decfloat","numeric","simple","xsequence","accp","char","clnt","cuky","curr","datn","dats","d16d","d16n","d16r","d34d","d34n","d34r","dec","df16_dec","df16_raw","df34_dec","df34_raw","fltp","geom_ewkb","int1","int2","int4","lang","lchr","lraw","numc","quan","raw","rawstring","sstring","timn","tims","unit","utcl","df16_scl","df34_scl","prec","varc","abap_bool","abap_false","abap_true","abap_undefined","me","screen","space","super","sy","syst","table_line","*sys*"],builtinMethods:["class_constructor","constructor"],derivedTypes:["%CID","%CID_REF","%CONTROL","%DATA","%ELEMENT","%FAIL","%KEY","%MSG","%PARAM","%PID","%PID_ASSOC","%PID_PARENT","%_HINTS"],cdsLanguage:["@AbapAnnotation","@AbapCatalog","@AccessControl","@API","@ClientDependent","@ClientHandling","@CompatibilityContract","@DataAging","@EndUserText","@Environment","@LanguageDependency","@MappingRole","@Metadata","@MetadataExtension","@ObjectModel","@Scope","@Semantics","$EXTENSION","$SELF"],selectors:["->","->*","=>","~","~*"],operators:[" +"," -","/","*","**","div","mod","=","#","@","+=","-=","*=","/=","**=","&&=","?=","&","&&","bit-and","bit-not","bit-or","bit-xor","m","o","z","<"," >","<=",">=","<>","><","=<","=>","bt","byte-ca","byte-cn","byte-co","byte-cs","byte-na","byte-ns","ca","cn","co","cp","cs","eq","ge","gt","le","lt","na","nb","ne","np","ns","*/","*:","--","/*","//"],symbols:/[=>))*/,{cases:{"@typeKeywords":"type","@keywords":"keyword","@cdsLanguage":"annotation","@derivedTypes":"type","@builtinFunctions":"type","@builtinMethods":"type","@operators":"key","@default":"identifier"}}],[/<[\w]+>/,"identifier"],[/##[\w|_]+/,"comment"],{include:"@whitespace"},[/[:,.]/,"delimiter"],[/[{}()\[\]]/,"@brackets"],[/@symbols/,{cases:{"@selectors":"tag","@operators":"key","@default":""}}],[/'/,{token:"string",bracket:"@open",next:"@stringquote"}],[/`/,{token:"string",bracket:"@open",next:"@stringping"}],[/\|/,{token:"string",bracket:"@open",next:"@stringtemplate"}],[/\d+/,"number"]],stringtemplate:[[/[^\\\|]+/,"string"],[/\\\|/,"string"],[/\|/,{token:"string",bracket:"@close",next:"@pop"}]],stringping:[[/[^\\`]+/,"string"],[/`/,{token:"string",bracket:"@close",next:"@pop"}]],stringquote:[[/[^\\']+/,"string"],[/'/,{token:"string",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,""],[/^\*.*$/,"comment"],[/\".*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56405.5fa107d3.chunk.js b/ydb/core/viewer/monitoring/static/js/56405.5fa107d3.chunk.js new file mode 100644 index 000000000000..6dacc82f03cf --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56405.5fa107d3.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56405],{56405:function(e,t,n){!function(e,t){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var r=n(t),u={1:"\u0661",2:"\u0662",3:"\u0663",4:"\u0664",5:"\u0665",6:"\u0666",7:"\u0667",8:"\u0668",9:"\u0669",0:"\u0660"},d={"\u0661":"1","\u0662":"2","\u0663":"3","\u0664":"4","\u0665":"5","\u0666":"6","\u0667":"7","\u0668":"8","\u0669":"9","\u0660":"0"},a=["\u06a9\u0627\u0646\u0648\u0648\u0646\u06cc \u062f\u0648\u0648\u06d5\u0645","\u0634\u0648\u0628\u0627\u062a","\u0626\u0627\u062f\u0627\u0631","\u0646\u06cc\u0633\u0627\u0646","\u0626\u0627\u06cc\u0627\u0631","\u062d\u0648\u0632\u06d5\u06cc\u0631\u0627\u0646","\u062a\u06d5\u0645\u0645\u0648\u0648\u0632","\u0626\u0627\u0628","\u0626\u06d5\u06cc\u0644\u0648\u0648\u0644","\u062a\u0634\u0631\u06cc\u0646\u06cc \u06cc\u06d5\u06a9\u06d5\u0645","\u062a\u0634\u0631\u06cc\u0646\u06cc \u062f\u0648\u0648\u06d5\u0645","\u06a9\u0627\u0646\u0648\u0648\u0646\u06cc \u06cc\u06d5\u06a9\u06d5\u0645"],i={name:"ku",months:a,monthsShort:a,weekdays:"\u06cc\u06d5\u06a9\u0634\u06d5\u0645\u0645\u06d5_\u062f\u0648\u0648\u0634\u06d5\u0645\u0645\u06d5_\u0633\u06ce\u0634\u06d5\u0645\u0645\u06d5_\u0686\u0648\u0627\u0631\u0634\u06d5\u0645\u0645\u06d5_\u067e\u06ce\u0646\u062c\u0634\u06d5\u0645\u0645\u06d5_\u0647\u06d5\u06cc\u0646\u06cc_\u0634\u06d5\u0645\u0645\u06d5".split("_"),weekdaysShort:"\u06cc\u06d5\u06a9\u0634\u06d5\u0645_\u062f\u0648\u0648\u0634\u06d5\u0645_\u0633\u06ce\u0634\u06d5\u0645_\u0686\u0648\u0627\u0631\u0634\u06d5\u0645_\u067e\u06ce\u0646\u062c\u0634\u06d5\u0645_\u0647\u06d5\u06cc\u0646\u06cc_\u0634\u06d5\u0645\u0645\u06d5".split("_"),weekStart:6,weekdaysMin:"\u06cc_\u062f_\u0633_\u0686_\u067e_\u0647\u0640_\u0634".split("_"),preparse:function(e){return e.replace(/[\u0661\u0662\u0663\u0664\u0665\u0666\u0667\u0668\u0669\u0660]/g,(function(e){return d[e]})).replace(/\u060c/g,",")},postformat:function(e){return e.replace(/\d/g,(function(e){return u[e]})).replace(/,/g,"\u060c")},ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},meridiem:function(e){return e<12?"\u067e.\u0646":"\u062f.\u0646"},relativeTime:{future:"\u0644\u06d5 %s",past:"\u0644\u06d5\u0645\u06d5\u0648\u067e\u06ce\u0634 %s",s:"\u0686\u06d5\u0646\u062f \u0686\u0631\u06a9\u06d5\u06cc\u06d5\u06a9",m:"\u06cc\u06d5\u06a9 \u062e\u0648\u0644\u06d5\u06a9",mm:"%d \u062e\u0648\u0644\u06d5\u06a9",h:"\u06cc\u06d5\u06a9 \u06a9\u0627\u062a\u0698\u0645\u06ce\u0631",hh:"%d \u06a9\u0627\u062a\u0698\u0645\u06ce\u0631",d:"\u06cc\u06d5\u06a9 \u0695\u06c6\u0698",dd:"%d \u0695\u06c6\u0698",M:"\u06cc\u06d5\u06a9 \u0645\u0627\u0646\u06af",MM:"%d \u0645\u0627\u0646\u06af",y:"\u06cc\u06d5\u06a9 \u0633\u0627\u06b5",yy:"%d \u0633\u0627\u06b5"}};r.default.locale(i,null,!0),e.default=i,e.englishToArabicNumbersMap=u,Object.defineProperty(e,"__esModule",{value:!0})}(t,n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56421.a250ca1b.chunk.js b/ydb/core/viewer/monitoring/static/js/56421.a250ca1b.chunk.js new file mode 100644 index 000000000000..f6d4ad8f3fd7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56421.a250ca1b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56421],{56421:(e,a,t)=>{t.d(a,{default:()=>s});var n=t(89488);const s=t.n(n)()},89488:e=>{function a(e){!function(e){var a=/\b(?:abstract|assert|boolean|break|byte|case|catch|char|class|const|continue|default|do|double|else|enum|exports|extends|final|finally|float|for|goto|if|implements|import|instanceof|int|interface|long|module|native|new|non-sealed|null|open|opens|package|permits|private|protected|provides|public|record|requires|return|sealed|short|static|strictfp|super|switch|synchronized|this|throw|throws|to|transient|transitive|try|uses|var|void|volatile|while|with|yield)\b/,t=/(^|[^\w.])(?:[a-z]\w*\s*\.\s*)*(?:[A-Z]\w*\s*\.\s*)*/.source,n={pattern:RegExp(t+/[A-Z](?:[\d_A-Z]*[a-z]\w*)?\b/.source),lookbehind:!0,inside:{namespace:{pattern:/^[a-z]\w*(?:\s*\.\s*[a-z]\w*)*(?:\s*\.)?/,inside:{punctuation:/\./}},punctuation:/\./}};e.languages.java=e.languages.extend("clike",{string:{pattern:/(^|[^\\])"(?:\\.|[^"\\\r\n])*"/,lookbehind:!0,greedy:!0},"class-name":[n,{pattern:RegExp(t+/[A-Z]\w*(?=\s+\w+\s*[;,=()])/.source),lookbehind:!0,inside:n.inside}],keyword:a,function:[e.languages.clike.function,{pattern:/(::\s*)[a-z_]\w*/,lookbehind:!0}],number:/\b0b[01][01_]*L?\b|\b0x(?:\.[\da-f_p+-]+|[\da-f_]+(?:\.[\da-f_p+-]+)?)\b|(?:\b\d[\d_]*(?:\.[\d_]*)?|\B\.\d[\d_]*)(?:e[+-]?\d[\d_]*)?[dfl]?/i,operator:{pattern:/(^|[^.])(?:<<=?|>>>?=?|->|--|\+\+|&&|\|\||::|[?:~]|[-+*/%&|^!=<>]=?)/m,lookbehind:!0}}),e.languages.insertBefore("java","string",{"triple-quoted-string":{pattern:/"""[ \t]*[\r\n](?:(?:"|"")?(?:\\.|[^"\\]))*"""/,greedy:!0,alias:"string"},char:{pattern:/'(?:\\.|[^'\\\r\n]){1,6}'/,greedy:!0}}),e.languages.insertBefore("java","class-name",{annotation:{pattern:/(^|[^.])@\w+(?:\s*\.\s*\w+)*/,lookbehind:!0,alias:"punctuation"},generics:{pattern:/<(?:[\w\s,.?]|&(?!&)|<(?:[\w\s,.?]|&(?!&)|<(?:[\w\s,.?]|&(?!&)|<(?:[\w\s,.?]|&(?!&))*>)*>)*>)*>/,inside:{"class-name":n,keyword:a,punctuation:/[<>(),.:]/,operator:/[?&|]/}},namespace:{pattern:RegExp(/(\b(?:exports|import(?:\s+static)?|module|open|opens|package|provides|requires|to|transitive|uses|with)\s+)(?!)[a-z]\w*(?:\.[a-z]\w*)*\.?/.source.replace(//g,(function(){return a.source}))),lookbehind:!0,inside:{punctuation:/\./}}})}(e)}e.exports=a,a.displayName="java",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56761.638c1141.chunk.js b/ydb/core/viewer/monitoring/static/js/56761.638c1141.chunk.js new file mode 100644 index 000000000000..7f2e9768346b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56761.638c1141.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56761],{56761:(e,t,a)=>{a.d(t,{default:()=>r});var s=a(80694);const r=a.n(s)()},80694:e=>{function t(e){e.languages.uorazor={"comment-hash":{pattern:/#.*/,alias:"comment",greedy:!0},"comment-slash":{pattern:/\/\/.*/,alias:"comment",greedy:!0},string:{pattern:/("|')(?:\\.|(?!\1)[^\\\r\n])*\1/,inside:{punctuation:/^['"]|['"]$/},greedy:!0},"source-layers":{pattern:/\b(?:arms|backpack|blue|bracelet|cancel|clear|cloak|criminal|earrings|enemy|facialhair|friend|friendly|gloves|gray|grey|ground|hair|head|innerlegs|innertorso|innocent|lefthand|middletorso|murderer|neck|nonfriendly|onehandedsecondary|outerlegs|outertorso|pants|red|righthand|ring|self|shirt|shoes|talisman|waist)\b/i,alias:"function"},"source-commands":{pattern:/\b(?:alliance|attack|cast|clearall|clearignore|clearjournal|clearlist|clearsysmsg|createlist|createtimer|dclick|dclicktype|dclickvar|dress|dressconfig|drop|droprelloc|emote|getlabel|guild|gumpclose|gumpresponse|hotkey|ignore|lasttarget|lift|lifttype|menu|menuresponse|msg|org|organize|organizer|overhead|pause|poplist|potion|promptresponse|pushlist|removelist|removetimer|rename|restock|say|scav|scavenger|script|setability|setlasttarget|setskill|settimer|setvar|sysmsg|target|targetloc|targetrelloc|targettype|undress|unignore|unsetvar|useobject|useonce|useskill|usetype|virtue|wait|waitforgump|waitformenu|waitforprompt|waitforstat|waitforsysmsg|waitfortarget|walk|wfsysmsg|wft|whisper|yell)\b/,alias:"function"},"tag-name":{pattern:/(^\{%-?\s*)\w+/,lookbehind:!0,alias:"keyword"},delimiter:{pattern:/^\{[{%]-?|-?[%}]\}$/,alias:"punctuation"},function:/\b(?:atlist|close|closest|count|counter|counttype|dead|dex|diffhits|diffmana|diffstam|diffweight|find|findbuff|finddebuff|findlayer|findtype|findtypelist|followers|gumpexists|hidden|hits|hp|hue|human|humanoid|ingump|inlist|insysmessage|insysmsg|int|invul|lhandempty|list|listexists|mana|maxhits|maxhp|maxmana|maxstam|maxweight|monster|mounted|name|next|noto|paralyzed|poisoned|position|prev|previous|queued|rand|random|rhandempty|skill|stam|str|targetexists|timer|timerexists|varexist|warmode|weight)\b/,keyword:/\b(?:and|as|break|continue|else|elseif|endfor|endif|endwhile|for|if|loop|not|or|replay|stop|while)\b/,boolean:/\b(?:false|null|true)\b/,number:/\b0x[\dA-Fa-f]+|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee][-+]?\d+)?/,operator:[{pattern:/(\s)(?:and|b-and|b-or|b-xor|ends with|in|is|matches|not|or|same as|starts with)(?=\s)/,lookbehind:!0},/[=<>]=?|!=|\*\*?|\/\/?|\?:?|[-+~%|]/],punctuation:/[()\[\]{}:.,]/}}e.exports=t,t.displayName="uorazor",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5685.c0a21a10.chunk.js b/ydb/core/viewer/monitoring/static/js/5685.c0a21a10.chunk.js deleted file mode 100644 index 724c5b2171fb..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5685.c0a21a10.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5685],{45685:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-iq",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0634\u0628\u0627\u0637_\u0622\u0630\u0627\u0631_\u0646\u064a\u0633\u0627\u0646_\u0623\u064a\u0627\u0631_\u062d\u0632\u064a\u0631\u0627\u0646_\u062a\u0645\u0648\u0632_\u0622\u0628_\u0623\u064a\u0644\u0648\u0644_\u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u0623\u0648\u0644_ \u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u0623\u0648\u0644".split("_"),weekStart:1,weekdaysShort:"\u0623\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0623\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0634\u0628\u0627\u0637_\u0622\u0630\u0627\u0631_\u0646\u064a\u0633\u0627\u0646_\u0623\u064a\u0627\u0631_\u062d\u0632\u064a\u0631\u0627\u0646_\u062a\u0645\u0648\u0632_\u0622\u0628_\u0623\u064a\u0644\u0648\u0644_\u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u0623\u0648\u0644_ \u062a\u0634\u0631\u064a\u0646 \u0627\u0644\u062b\u0627\u0646\u064a_\u0643\u0627\u0646\u0648\u0646 \u0627\u0644\u0623\u0648\u0644".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/56990.be6d200f.chunk.js b/ydb/core/viewer/monitoring/static/js/56990.be6d200f.chunk.js new file mode 100644 index 000000000000..8f6be773c72f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/56990.be6d200f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[56990],{56990:(e,l,t)=>{t.r(l),t.d(l,{ReactComponent:()=>m,default:()=>h});var a,r,i,n,c,d,o,s,f=t(59284);function u(){return u=Object.assign?Object.assign.bind():function(e){for(var l=1;l{t.d(a,{default:()=>E});var n=t(72681);const E=t.n(n)()},70586:e=>{function a(e){e.languages.turtle={comment:{pattern:/#.*/,greedy:!0},"multiline-string":{pattern:/"""(?:(?:""?)?(?:[^"\\]|\\.))*"""|'''(?:(?:''?)?(?:[^'\\]|\\.))*'''/,greedy:!0,alias:"string",inside:{comment:/#.*/}},string:{pattern:/"(?:[^\\"\r\n]|\\.)*"|'(?:[^\\'\r\n]|\\.)*'/,greedy:!0},url:{pattern:/<(?:[^\x00-\x20<>"{}|^`\\]|\\(?:u[\da-fA-F]{4}|U[\da-fA-F]{8}))*>/,greedy:!0,inside:{punctuation:/[<>]/}},function:{pattern:/(?:(?![-.\d\xB7])[-.\w\xB7\xC0-\uFFFD]+)?:(?:(?![-.])(?:[-.:\w\xC0-\uFFFD]|%[\da-f]{2}|\\.)+)?/i,inside:{"local-name":{pattern:/([^:]*:)[\s\S]+/,lookbehind:!0},prefix:{pattern:/[\s\S]+/,inside:{punctuation:/:/}}}},number:/[+-]?\b\d+(?:\.\d*)?(?:e[+-]?\d+)?/i,punctuation:/[{}.,;()[\]]|\^\^/,boolean:/\b(?:false|true)\b/,keyword:[/(?:\ba|@prefix|@base)\b|=/,/\b(?:base|graph|prefix)\b/i],tag:{pattern:/@[a-z]+(?:-[a-z\d]+)*/i,inside:{punctuation:/@/}}},e.languages.trig=e.languages.turtle}e.exports=a,a.displayName="turtle",a.aliases=[]},72681:(e,a,t)=>{var n=t(70586);function E(e){e.register(n),e.languages.sparql=e.languages.extend("turtle",{boolean:/\b(?:false|true)\b/i,variable:{pattern:/[?$]\w+/,greedy:!0}}),e.languages.insertBefore("sparql","punctuation",{keyword:[/\b(?:A|ADD|ALL|AS|ASC|ASK|BNODE|BY|CLEAR|CONSTRUCT|COPY|CREATE|DATA|DEFAULT|DELETE|DESC|DESCRIBE|DISTINCT|DROP|EXISTS|FILTER|FROM|GROUP|HAVING|INSERT|INTO|LIMIT|LOAD|MINUS|MOVE|NAMED|NOT|NOW|OFFSET|OPTIONAL|ORDER|RAND|REDUCED|SELECT|SEPARATOR|SERVICE|SILENT|STRUUID|UNION|USING|UUID|VALUES|WHERE)\b/i,/\b(?:ABS|AVG|BIND|BOUND|CEIL|COALESCE|CONCAT|CONTAINS|COUNT|DATATYPE|DAY|ENCODE_FOR_URI|FLOOR|GROUP_CONCAT|HOURS|IF|IRI|isBLANK|isIRI|isLITERAL|isNUMERIC|isURI|LANG|LANGMATCHES|LCASE|MAX|MD5|MIN|MINUTES|MONTH|REGEX|REPLACE|ROUND|sameTerm|SAMPLE|SECONDS|SHA1|SHA256|SHA384|SHA512|STR|STRAFTER|STRBEFORE|STRDT|STRENDS|STRLANG|STRLEN|STRSTARTS|SUBSTR|SUM|TIMEZONE|TZ|UCASE|URI|YEAR)\b(?=\s*\()/i,/\b(?:BASE|GRAPH|PREFIX)\b/i]}),e.languages.rq=e.languages.sparql}e.exports=E,E.displayName="sparql",E.aliases=["rq"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/57118.e38774e7.chunk.js b/ydb/core/viewer/monitoring/static/js/57118.e38774e7.chunk.js new file mode 100644 index 000000000000..59b33e50a629 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57118.e38774e7.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 57118.e38774e7.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57118],{57118:(e,o,n)=>{n.r(o),n.d(o,{conf:()=>t,language:()=>s});var t={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}]},s={defaultToken:"",tokenPostfix:".pascaligo",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["begin","block","case","const","else","end","fail","for","from","function","if","is","nil","of","remove","return","skip","then","type","var","while","with","option","None","transaction"],typeKeywords:["bool","int","list","map","nat","record","string","unit","address","map","mtz","xtz"],operators:["=",">","<","<=",">=","<>",":",":=","and","mod","or","+","-","*","/","@","&","^","%"],symbols:/[=><:@\^&|+\-*\/\^%]+/,tokenizer:{root:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\$[0-9a-fA-F]{1,16}/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'/,"string","@string"],[/'[^\\']'/,"string"],[/'/,"string.invalid"],[/\#\d+/,"string"]],comment:[[/[^\(\*]+/,"comment"],[/\*\)/,"comment","@pop"],[/\(\*/,"comment"]],string:[[/[^\\']+/,"string"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"],[/\(\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5988.38ef363d.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/57118.e38774e7.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/5988.38ef363d.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/57118.e38774e7.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/57206.7544a09d.chunk.js b/ydb/core/viewer/monitoring/static/js/57206.7544a09d.chunk.js new file mode 100644 index 000000000000..7b511293401e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57206.7544a09d.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 57206.7544a09d.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57206],{57206:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>r,language:()=>s});var r={comments:{lineComment:";;"},brackets:[["[","]"],["(",")"],["{","}"]],autoClosingPairs:[{open:"[",close:"]"},{open:'"',close:'"'},{open:"(",close:")"},{open:"{",close:"}"}],surroundingPairs:[{open:"[",close:"]"},{open:'"',close:'"'},{open:"(",close:")"},{open:"{",close:"}"}]},s={defaultToken:"",ignoreCase:!0,tokenPostfix:".clj",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"}],constants:["true","false","nil"],numbers:/^(?:[+\-]?\d+(?:(?:N|(?:[eE][+\-]?\d+))|(?:\.?\d*(?:M|(?:[eE][+\-]?\d+))?)|\/\d+|[xX][0-9a-fA-F]+|r[0-9a-zA-Z]+)?(?=[\\\[\]\s"#'(),;@^`{}~]|$))/,characters:/^(?:\\(?:backspace|formfeed|newline|return|space|tab|o[0-7]{3}|u[0-9A-Fa-f]{4}|x[0-9A-Fa-f]{4}|.)?(?=[\\\[\]\s"(),;@^`{}~]|$))/,escapes:/^\\(?:["'\\bfnrt]|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,qualifiedSymbols:/^(?:(?:[^\\\/\[\]\d\s"#'(),;@^`{}~][^\\\[\]\s"(),;@^`{}~]*(?:\.[^\\\/\[\]\d\s"#'(),;@^`{}~][^\\\[\]\s"(),;@^`{}~]*)*\/)?(?:\/|[^\\\/\[\]\d\s"#'(),;@^`{}~][^\\\[\]\s"(),;@^`{}~]*)*(?=[\\\[\]\s"(),;@^`{}~]|$))/,specialForms:[".","catch","def","do","if","monitor-enter","monitor-exit","new","quote","recur","set!","throw","try","var"],coreSymbols:["*","*'","*1","*2","*3","*agent*","*allow-unresolved-vars*","*assert*","*clojure-version*","*command-line-args*","*compile-files*","*compile-path*","*compiler-options*","*data-readers*","*default-data-reader-fn*","*e","*err*","*file*","*flush-on-newline*","*fn-loader*","*in*","*math-context*","*ns*","*out*","*print-dup*","*print-length*","*print-level*","*print-meta*","*print-namespace-maps*","*print-readably*","*read-eval*","*reader-resolver*","*source-path*","*suppress-read*","*unchecked-math*","*use-context-classloader*","*verbose-defrecords*","*warn-on-reflection*","+","+'","-","-'","->","->>","->ArrayChunk","->Eduction","->Vec","->VecNode","->VecSeq","-cache-protocol-fn","-reset-methods","..","/","<","<=","=","==",">",">=","EMPTY-NODE","Inst","StackTraceElement->vec","Throwable->map","accessor","aclone","add-classpath","add-watch","agent","agent-error","agent-errors","aget","alength","alias","all-ns","alter","alter-meta!","alter-var-root","amap","ancestors","and","any?","apply","areduce","array-map","as->","aset","aset-boolean","aset-byte","aset-char","aset-double","aset-float","aset-int","aset-long","aset-short","assert","assoc","assoc!","assoc-in","associative?","atom","await","await-for","await1","bases","bean","bigdec","bigint","biginteger","binding","bit-and","bit-and-not","bit-clear","bit-flip","bit-not","bit-or","bit-set","bit-shift-left","bit-shift-right","bit-test","bit-xor","boolean","boolean-array","boolean?","booleans","bound-fn","bound-fn*","bound?","bounded-count","butlast","byte","byte-array","bytes","bytes?","case","cast","cat","char","char-array","char-escape-string","char-name-string","char?","chars","chunk","chunk-append","chunk-buffer","chunk-cons","chunk-first","chunk-next","chunk-rest","chunked-seq?","class","class?","clear-agent-errors","clojure-version","coll?","comment","commute","comp","comparator","compare","compare-and-set!","compile","complement","completing","concat","cond","cond->","cond->>","condp","conj","conj!","cons","constantly","construct-proxy","contains?","count","counted?","create-ns","create-struct","cycle","dec","dec'","decimal?","declare","dedupe","default-data-readers","definline","definterface","defmacro","defmethod","defmulti","defn","defn-","defonce","defprotocol","defrecord","defstruct","deftype","delay","delay?","deliver","denominator","deref","derive","descendants","destructure","disj","disj!","dissoc","dissoc!","distinct","distinct?","doall","dorun","doseq","dosync","dotimes","doto","double","double-array","double?","doubles","drop","drop-last","drop-while","eduction","empty","empty?","ensure","ensure-reduced","enumeration-seq","error-handler","error-mode","eval","even?","every-pred","every?","ex-data","ex-info","extend","extend-protocol","extend-type","extenders","extends?","false?","ffirst","file-seq","filter","filterv","find","find-keyword","find-ns","find-protocol-impl","find-protocol-method","find-var","first","flatten","float","float-array","float?","floats","flush","fn","fn?","fnext","fnil","for","force","format","frequencies","future","future-call","future-cancel","future-cancelled?","future-done?","future?","gen-class","gen-interface","gensym","get","get-in","get-method","get-proxy-class","get-thread-bindings","get-validator","group-by","halt-when","hash","hash-combine","hash-map","hash-ordered-coll","hash-set","hash-unordered-coll","ident?","identical?","identity","if-let","if-not","if-some","ifn?","import","in-ns","inc","inc'","indexed?","init-proxy","inst-ms","inst-ms*","inst?","instance?","int","int-array","int?","integer?","interleave","intern","interpose","into","into-array","ints","io!","isa?","iterate","iterator-seq","juxt","keep","keep-indexed","key","keys","keyword","keyword?","last","lazy-cat","lazy-seq","let","letfn","line-seq","list","list*","list?","load","load-file","load-reader","load-string","loaded-libs","locking","long","long-array","longs","loop","macroexpand","macroexpand-1","make-array","make-hierarchy","map","map-entry?","map-indexed","map?","mapcat","mapv","max","max-key","memfn","memoize","merge","merge-with","meta","method-sig","methods","min","min-key","mix-collection-hash","mod","munge","name","namespace","namespace-munge","nat-int?","neg-int?","neg?","newline","next","nfirst","nil?","nnext","not","not-any?","not-empty","not-every?","not=","ns","ns-aliases","ns-imports","ns-interns","ns-map","ns-name","ns-publics","ns-refers","ns-resolve","ns-unalias","ns-unmap","nth","nthnext","nthrest","num","number?","numerator","object-array","odd?","or","parents","partial","partition","partition-all","partition-by","pcalls","peek","persistent!","pmap","pop","pop!","pop-thread-bindings","pos-int?","pos?","pr","pr-str","prefer-method","prefers","primitives-classnames","print","print-ctor","print-dup","print-method","print-simple","print-str","printf","println","println-str","prn","prn-str","promise","proxy","proxy-call-with-super","proxy-mappings","proxy-name","proxy-super","push-thread-bindings","pvalues","qualified-ident?","qualified-keyword?","qualified-symbol?","quot","rand","rand-int","rand-nth","random-sample","range","ratio?","rational?","rationalize","re-find","re-groups","re-matcher","re-matches","re-pattern","re-seq","read","read-line","read-string","reader-conditional","reader-conditional?","realized?","record?","reduce","reduce-kv","reduced","reduced?","reductions","ref","ref-history-count","ref-max-history","ref-min-history","ref-set","refer","refer-clojure","reify","release-pending-sends","rem","remove","remove-all-methods","remove-method","remove-ns","remove-watch","repeat","repeatedly","replace","replicate","require","reset!","reset-meta!","reset-vals!","resolve","rest","restart-agent","resultset-seq","reverse","reversible?","rseq","rsubseq","run!","satisfies?","second","select-keys","send","send-off","send-via","seq","seq?","seqable?","seque","sequence","sequential?","set","set-agent-send-executor!","set-agent-send-off-executor!","set-error-handler!","set-error-mode!","set-validator!","set?","short","short-array","shorts","shuffle","shutdown-agents","simple-ident?","simple-keyword?","simple-symbol?","slurp","some","some->","some->>","some-fn","some?","sort","sort-by","sorted-map","sorted-map-by","sorted-set","sorted-set-by","sorted?","special-symbol?","spit","split-at","split-with","str","string?","struct","struct-map","subs","subseq","subvec","supers","swap!","swap-vals!","symbol","symbol?","sync","tagged-literal","tagged-literal?","take","take-last","take-nth","take-while","test","the-ns","thread-bound?","time","to-array","to-array-2d","trampoline","transduce","transient","tree-seq","true?","type","unchecked-add","unchecked-add-int","unchecked-byte","unchecked-char","unchecked-dec","unchecked-dec-int","unchecked-divide-int","unchecked-double","unchecked-float","unchecked-inc","unchecked-inc-int","unchecked-int","unchecked-long","unchecked-multiply","unchecked-multiply-int","unchecked-negate","unchecked-negate-int","unchecked-remainder-int","unchecked-short","unchecked-subtract","unchecked-subtract-int","underive","unquote","unquote-splicing","unreduced","unsigned-bit-shift-right","update","update-in","update-proxy","uri?","use","uuid?","val","vals","var-get","var-set","var?","vary-meta","vec","vector","vector-of","vector?","volatile!","volatile?","vreset!","vswap!","when","when-first","when-let","when-not","when-some","while","with-bindings","with-bindings*","with-in-str","with-loading-context","with-local-vars","with-meta","with-open","with-out-str","with-precision","with-redefs","with-redefs-fn","xml-seq","zero?","zipmap"],tokenizer:{root:[{include:"@whitespace"},[/@numbers/,"number"],[/@characters/,"string"],{include:"@string"},[/[()\[\]{}]/,"@brackets"],[/\/#"(?:\.|(?:")|[^"\n])*"\/g/,"regexp"],[/[#'@^`~]/,"meta"],[/@qualifiedSymbols/,{cases:{"^:.+$":"constant","@specialForms":"keyword","@coreSymbols":"keyword","@constants":"constant","@default":"identifier"}}]],whitespace:[[/[\s,]+/,"white"],[/;.*$/,"comment"],[/\(comment\b/,"comment","@comment"]],comment:[[/\(/,"comment","@push"],[/\)/,"comment","@pop"],[/[^()]/,"comment"]],string:[[/"/,"string","@multiLineString"]],multiLineString:[[/"/,"string","@popall"],[/@escapes/,"string.escape"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6012.aac08e72.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/57206.7544a09d.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6012.aac08e72.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/57206.7544a09d.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/57320.74fc8316.chunk.js b/ydb/core/viewer/monitoring/static/js/57320.74fc8316.chunk.js new file mode 100644 index 000000000000..cfc6dd3e8e8d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57320.74fc8316.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57320],{5819:(e,n,a)=>{var s=a(24450);function t(e){e.register(s),function(e){var n=/("|')(?:\\(?:\r\n?|\n|.)|(?!\1)[^\\\r\n])*\1/;e.languages.json5=e.languages.extend("json",{property:[{pattern:RegExp(n.source+"(?=\\s*:)"),greedy:!0},{pattern:/(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*:)/,alias:"unquoted"}],string:{pattern:n,greedy:!0},number:/[+-]?\b(?:NaN|Infinity|0x[a-fA-F\d]+)\b|[+-]?(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[eE][+-]?\d+\b)?/})}(e)}e.exports=t,t.displayName="json5",t.aliases=[]},24450:e=>{function n(e){e.languages.json={property:{pattern:/(^|[^\\])"(?:\\.|[^\\"\r\n])*"(?=\s*:)/,lookbehind:!0,greedy:!0},string:{pattern:/(^|[^\\])"(?:\\.|[^\\"\r\n])*"(?!\s*:)/,lookbehind:!0,greedy:!0},comment:{pattern:/\/\/.*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},number:/-?\b\d+(?:\.\d+)?(?:e[+-]?\d+)?\b/i,punctuation:/[{}[\],]/,operator:/:/,boolean:/\b(?:false|true)\b/,null:{pattern:/\bnull\b/,alias:"keyword"}},e.languages.webmanifest=e.languages.json}e.exports=n,n.displayName="json",n.aliases=["webmanifest"]},57320:(e,n,a)=>{a.d(n,{default:()=>t});var s=a(5819);const t=a.n(s)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/57469.85faf9a5.chunk.js b/ydb/core/viewer/monitoring/static/js/57469.85faf9a5.chunk.js new file mode 100644 index 000000000000..b13981003a1a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57469.85faf9a5.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57469],{57469:(e,a,d)=>{d.d(a,{default:()=>l});var r=d(77678);const l=d.n(r)()},77678:e=>{function a(e){e.languages.purebasic=e.languages.extend("clike",{comment:/;.*/,keyword:/\b(?:align|and|as|break|calldebugger|case|compilercase|compilerdefault|compilerelse|compilerelseif|compilerendif|compilerendselect|compilererror|compilerif|compilerselect|continue|data|datasection|debug|debuglevel|declare|declarec|declarecdll|declaredll|declaremodule|default|define|dim|disableasm|disabledebugger|disableexplicit|else|elseif|enableasm|enabledebugger|enableexplicit|end|enddatasection|enddeclaremodule|endenumeration|endif|endimport|endinterface|endmacro|endmodule|endprocedure|endselect|endstructure|endstructureunion|endwith|enumeration|extends|fakereturn|for|foreach|forever|global|gosub|goto|if|import|importc|includebinary|includefile|includepath|interface|macro|module|newlist|newmap|next|not|or|procedure|procedurec|procedurecdll|proceduredll|procedurereturn|protected|prototype|prototypec|read|redim|repeat|restore|return|runtime|select|shared|static|step|structure|structureunion|swap|threaded|to|until|wend|while|with|xincludefile|xor)\b/i,function:/\b\w+(?:\.\w+)?\s*(?=\()/,number:/(?:\$[\da-f]+|\b-?(?:\d+(?:\.\d+)?|\.\d+)(?:e[+-]?\d+)?)\b/i,operator:/(?:@\*?|\?|\*)\w+|-[>-]?|\+\+?|!=?|<>?=?|==?|&&?|\|?\||[~^%?*/@]/}),e.languages.insertBefore("purebasic","keyword",{tag:/#\w+\$?/,asm:{pattern:/(^[\t ]*)!.*/m,lookbehind:!0,alias:"tag",inside:{comment:/;.*/,string:{pattern:/(["'`])(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0},"label-reference-anonymous":{pattern:/(!\s*j[a-z]+\s+)@[fb]/i,lookbehind:!0,alias:"fasm-label"},"label-reference-addressed":{pattern:/(!\s*j[a-z]+\s+)[A-Z._?$@][\w.?$@~#]*/i,lookbehind:!0,alias:"fasm-label"},keyword:[/\b(?:extern|global)\b[^;\r\n]*/i,/\b(?:CPU|DEFAULT|FLOAT)\b.*/],function:{pattern:/^([\t ]*!\s*)[\da-z]+(?=\s|$)/im,lookbehind:!0},"function-inline":{pattern:/(:\s*)[\da-z]+(?=\s)/i,lookbehind:!0,alias:"function"},label:{pattern:/^([\t ]*!\s*)[A-Za-z._?$@][\w.?$@~#]*(?=:)/m,lookbehind:!0,alias:"fasm-label"},register:/\b(?:st\d|[xyz]mm\d\d?|[cdt]r\d|r\d\d?[bwd]?|[er]?[abcd]x|[abcd][hl]|[er]?(?:bp|di|si|sp)|[cdefgs]s|mm\d+)\b/i,number:/(?:\b|-|(?=\$))(?:0[hx](?:[\da-f]*\.)?[\da-f]+(?:p[+-]?\d+)?|\d[\da-f]+[hx]|\$\d[\da-f]*|0[oq][0-7]+|[0-7]+[oq]|0[by][01]+|[01]+[by]|0[dt]\d+|(?:\d+(?:\.\d+)?|\.\d+)(?:\.?e[+-]?\d+)?[dt]?)\b/i,operator:/[\[\]*+\-/%<>=&|$!,.:]/}}}),delete e.languages.purebasic["class-name"],delete e.languages.purebasic.boolean,e.languages.pbfasm=e.languages.purebasic}e.exports=a,a.displayName="purebasic",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5759.52418ea5.chunk.js b/ydb/core/viewer/monitoring/static/js/5759.52418ea5.chunk.js deleted file mode 100644 index 26264729696b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5759.52418ea5.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5759],{45759:function(a,e,t){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var t=e(a),_={name:"eu",weekdays:"igandea_astelehena_asteartea_asteazkena_osteguna_ostirala_larunbata".split("_"),months:"urtarrila_otsaila_martxoa_apirila_maiatza_ekaina_uztaila_abuztua_iraila_urria_azaroa_abendua".split("_"),weekStart:1,weekdaysShort:"ig._al._ar._az._og._ol._lr.".split("_"),monthsShort:"urt._ots._mar._api._mai._eka._uzt._abu._ira._urr._aza._abe.".split("_"),weekdaysMin:"ig_al_ar_az_og_ol_lr".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY[ko] MMMM[ren] D[a]",LLL:"YYYY[ko] MMMM[ren] D[a] HH:mm",LLLL:"dddd, YYYY[ko] MMMM[ren] D[a] HH:mm",l:"YYYY-M-D",ll:"YYYY[ko] MMM D[a]",lll:"YYYY[ko] MMM D[a] HH:mm",llll:"ddd, YYYY[ko] MMM D[a] HH:mm"},relativeTime:{future:"%s barru",past:"duela %s",s:"segundo batzuk",m:"minutu bat",mm:"%d minutu",h:"ordu bat",hh:"%d ordu",d:"egun bat",dd:"%d egun",M:"hilabete bat",MM:"%d hilabete",y:"urte bat",yy:"%d urte"}};return t.default.locale(_,null,!0),_}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/57708.c2b518ee.chunk.js b/ydb/core/viewer/monitoring/static/js/57708.c2b518ee.chunk.js new file mode 100644 index 000000000000..88fcc463d800 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57708.c2b518ee.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57708],{23025:e=>{function a(e){e.languages.n4js=e.languages.extend("javascript",{keyword:/\b(?:Array|any|boolean|break|case|catch|class|const|constructor|continue|debugger|declare|default|delete|do|else|enum|export|extends|false|finally|for|from|function|get|if|implements|import|in|instanceof|interface|let|module|new|null|number|package|private|protected|public|return|set|static|string|super|switch|this|throw|true|try|typeof|var|void|while|with|yield)\b/}),e.languages.insertBefore("n4js","constant",{annotation:{pattern:/@+\w+/,alias:"operator"}}),e.languages.n4jsd=e.languages.n4js}e.exports=a,a.displayName="n4js",a.aliases=["n4jsd"]},57708:(e,a,t)=>{t.d(a,{default:()=>s});var n=t(23025);const s=t.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/57946.31f41343.chunk.js b/ydb/core/viewer/monitoring/static/js/57946.31f41343.chunk.js new file mode 100644 index 000000000000..8f449ec6839c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57946.31f41343.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 57946.31f41343.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57946],{57946:(e,o,n)=>{n.r(o),n.d(o,{conf:()=>t,language:()=>r});var t={comments:{lineComment:"'"},brackets:[["(",")"],["[","]"],["If","EndIf"],["While","EndWhile"],["For","EndFor"],["Sub","EndSub"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]}]},r={defaultToken:"",tokenPostfix:".sb",ignoreCase:!0,brackets:[{token:"delimiter.array",open:"[",close:"]"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"keyword.tag-if",open:"If",close:"EndIf"},{token:"keyword.tag-while",open:"While",close:"EndWhile"},{token:"keyword.tag-for",open:"For",close:"EndFor"},{token:"keyword.tag-sub",open:"Sub",close:"EndSub"}],keywords:["Else","ElseIf","EndFor","EndIf","EndSub","EndWhile","For","Goto","If","Step","Sub","Then","To","While"],tagwords:["If","Sub","While","For"],operators:[">","<","<>","<=",">=","And","Or","+","-","*","/","="],identifier:/[a-zA-Z_][\w]*/,symbols:/[=><:+\-*\/%\.,]+/,escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[{include:"@whitespace"},[/(@identifier)(?=[.])/,"type"],[/@identifier/,{cases:{"@keywords":{token:"keyword.$0"},"@operators":"operator","@default":"variable.name"}}],[/([.])(@identifier)/,{cases:{$2:["delimiter","type.member"],"@default":""}}],[/\d*\.\d+/,"number.float"],[/\d+/,"number"],[/[()\[\]]/,"@brackets"],[/@symbols/,{cases:{"@operators":"operator","@default":"delimiter"}}],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"]],whitespace:[[/[ \t\r\n]+/,""],[/(\').*$/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"C?/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6210.69d6a30a.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/57946.31f41343.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6210.69d6a30a.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/57946.31f41343.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/57970.67e88902.chunk.js b/ydb/core/viewer/monitoring/static/js/57970.67e88902.chunk.js new file mode 100644 index 000000000000..c4f6c976aa0e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/57970.67e88902.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[57970],{57970:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e),r={name:"hu",weekdays:"vas\xe1rnap_h\xe9tf\u0151_kedd_szerda_cs\xfct\xf6rt\xf6k_p\xe9ntek_szombat".split("_"),weekdaysShort:"vas_h\xe9t_kedd_sze_cs\xfct_p\xe9n_szo".split("_"),weekdaysMin:"v_h_k_sze_cs_p_szo".split("_"),months:"janu\xe1r_febru\xe1r_m\xe1rcius_\xe1prilis_m\xe1jus_j\xfanius_j\xfalius_augusztus_szeptember_okt\xf3ber_november_december".split("_"),monthsShort:"jan_feb_m\xe1rc_\xe1pr_m\xe1j_j\xfan_j\xfal_aug_szept_okt_nov_dec".split("_"),ordinal:function(e){return e+"."},weekStart:1,relativeTime:{future:"%s m\xfalva",past:"%s",s:function(e,n,t,r){return"n\xe9h\xe1ny m\xe1sodperc"+(r||n?"":"e")},m:function(e,n,t,r){return"egy perc"+(r||n?"":"e")},mm:function(e,n,t,r){return e+" perc"+(r||n?"":"e")},h:function(e,n,t,r){return"egy "+(r||n?"\xf3ra":"\xf3r\xe1ja")},hh:function(e,n,t,r){return e+" "+(r||n?"\xf3ra":"\xf3r\xe1ja")},d:function(e,n,t,r){return"egy "+(r||n?"nap":"napja")},dd:function(e,n,t,r){return e+" "+(r||n?"nap":"napja")},M:function(e,n,t,r){return"egy "+(r||n?"h\xf3nap":"h\xf3napja")},MM:function(e,n,t,r){return e+" "+(r||n?"h\xf3nap":"h\xf3napja")},y:function(e,n,t,r){return"egy "+(r||n?"\xe9v":"\xe9ve")},yy:function(e,n,t,r){return e+" "+(r||n?"\xe9v":"\xe9ve")}},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"YYYY.MM.DD.",LL:"YYYY. MMMM D.",LLL:"YYYY. MMMM D. H:mm",LLLL:"YYYY. MMMM D., dddd H:mm"}};return t.default.locale(r,null,!0),r}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5816.144b5755.chunk.js b/ydb/core/viewer/monitoring/static/js/5816.144b5755.chunk.js deleted file mode 100644 index f1ec44516b95..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5816.144b5755.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5816],{55816:function(e,_,n){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var n=_(e),t={name:"tk",weekdays:"\xddek\u015fenbe_Du\u015fenbe_Si\u015fenbe_\xc7ar\u015fenbe_Pen\u015fenbe_Anna_\u015eenbe".split("_"),weekdaysShort:"\xddek_Du\u015f_Si\u015f_\xc7ar_Pen_Ann_\u015een".split("_"),weekdaysMin:"\xddk_D\u015f_S\u015f_\xc7r_Pn_An_\u015en".split("_"),months:"\xddanwar_Fewral_Mart_Aprel_Ma\xfd_I\xfdun_I\xfdul_Awgust_Sent\xfdabr_Okt\xfdabr_No\xfdabr_Dekabr".split("_"),monthsShort:"\xddan_Few_Mar_Apr_Ma\xfd_I\xfdn_I\xfdl_Awg_Sen_Okt_No\xfd_Dek".split("_"),weekStart:1,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s so\u0148",past:"%s \xf6\u0148",s:"birn\xe4\xe7e sekunt",m:"bir minut",mm:"%d minut",h:"bir sagat",hh:"%d sagat",d:"bir g\xfcn",dd:"%d g\xfcn",M:"bir a\xfd",MM:"%d a\xfd",y:"bir \xfdyl",yy:"%d \xfdyl"},ordinal:function(e){return e+"."}};return n.default.locale(t,null,!0),t}(n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5819.0ae2eb3d.chunk.js b/ydb/core/viewer/monitoring/static/js/5819.0ae2eb3d.chunk.js deleted file mode 100644 index 0cc9dbe55834..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5819.0ae2eb3d.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5819],{95819:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),s={name:"lv",weekdays:"sv\u0113tdiena_pirmdiena_otrdiena_tre\u0161diena_ceturtdiena_piektdiena_sestdiena".split("_"),months:"janv\u0101ris_febru\u0101ris_marts_apr\u012blis_maijs_j\u016bnijs_j\u016blijs_augusts_septembris_oktobris_novembris_decembris".split("_"),weekStart:1,weekdaysShort:"Sv_P_O_T_C_Pk_S".split("_"),monthsShort:"jan_feb_mar_apr_mai_j\u016bn_j\u016bl_aug_sep_okt_nov_dec".split("_"),weekdaysMin:"Sv_P_O_T_C_Pk_S".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY.",LL:"YYYY. [gada] D. MMMM",LLL:"YYYY. [gada] D. MMMM, HH:mm",LLLL:"YYYY. [gada] D. MMMM, dddd, HH:mm"},relativeTime:{future:"p\u0113c %s",past:"pirms %s",s:"da\u017e\u0101m sekund\u0113m",m:"min\u016btes",mm:"%d min\u016bt\u0113m",h:"stundas",hh:"%d stund\u0101m",d:"dienas",dd:"%d dien\u0101m",M:"m\u0113ne\u0161a",MM:"%d m\u0113ne\u0161iem",y:"gada",yy:"%d gadiem"}};return a.default.locale(s,null,!0),s}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/58457.708b5a15.chunk.js b/ydb/core/viewer/monitoring/static/js/58457.708b5a15.chunk.js new file mode 100644 index 000000000000..2b810fd34ff2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/58457.708b5a15.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[58457],{58457:(e,a,n)=>{n.d(a,{default:()=>t});var s=n(76280);const t=n.n(s)()},76280:e=>{function a(e){e.languages.hoon={comment:{pattern:/::.*/,greedy:!0},string:{pattern:/"[^"]*"|'[^']*'/,greedy:!0},constant:/%(?:\.[ny]|[\w-]+)/,"class-name":/@(?:[a-z0-9-]*[a-z0-9])?|\*/i,function:/(?:\+[-+] {2})?(?:[a-z](?:[a-z0-9-]*[a-z0-9])?)/,keyword:/\.[\^\+\*=\?]|![><:\.=\?!]|=[>|:,\.\-\^<+;/~\*\?]|\?[>|:\.\-\^<\+&~=@!]|\|[\$_%:\.\-\^~\*=@\?]|\+[|\$\+\*]|:[_\-\^\+~\*]|%[_:\.\-\^\+~\*=]|\^[|:\.\-\+&~\*=\?]|\$[|_%:<>\-\^&~@=\?]|;[:<\+;\/~\*=]|~[>|\$_%<\+\/&=\?!]|--|==/}}e.exports=a,a.displayName="hoon",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5853.0c5ec1d1.chunk.js b/ydb/core/viewer/monitoring/static/js/5853.0c5ec1d1.chunk.js deleted file mode 100644 index 3e89310fc915..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5853.0c5ec1d1.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5853],{55853:function(s,i,e){s.exports=function(s){"use strict";function i(s){return s&&"object"==typeof s&&"default"in s?s:{default:s}}var e=i(s),M="sausio_vasario_kovo_baland\u017eio_gegu\u017e\u0117s_bir\u017eelio_liepos_rugpj\u016b\u010dio_rugs\u0117jo_spalio_lapkri\u010dio_gruod\u017eio".split("_"),a="sausis_vasaris_kovas_balandis_gegu\u017e\u0117_bir\u017eelis_liepa_rugpj\u016btis_rugs\u0117jis_spalis_lapkritis_gruodis".split("_"),d=/D[oD]?(\[[^\[\]]*\]|\s)+MMMM?|MMMM?(\[[^\[\]]*\]|\s)+D[oD]?/,l=function(s,i){return d.test(i)?M[s.month()]:a[s.month()]};l.s=a,l.f=M;var Y={name:"lt",weekdays:"sekmadienis_pirmadienis_antradienis_tre\u010diadienis_ketvirtadienis_penktadienis_\u0161e\u0161tadienis".split("_"),weekdaysShort:"sek_pir_ant_tre_ket_pen_\u0161e\u0161".split("_"),weekdaysMin:"s_p_a_t_k_pn_\u0161".split("_"),months:l,monthsShort:"sau_vas_kov_bal_geg_bir_lie_rgp_rgs_spa_lap_grd".split("_"),ordinal:function(s){return s+"."},weekStart:1,relativeTime:{future:"u\u017e %s",past:"prie\u0161 %s",s:"kelias sekundes",m:"minut\u0119",mm:"%d minutes",h:"valand\u0105",hh:"%d valandas",d:"dien\u0105",dd:"%d dienas",M:"m\u0117nes\u012f",MM:"%d m\u0117nesius",y:"metus",yy:"%d metus"},format:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY [m.] MMMM D [d.]",LLL:"YYYY [m.] MMMM D [d.], HH:mm [val.]",LLLL:"YYYY [m.] MMMM D [d.], dddd, HH:mm [val.]",l:"YYYY-MM-DD",ll:"YYYY [m.] MMMM D [d.]",lll:"YYYY [m.] MMMM D [d.], HH:mm [val.]",llll:"YYYY [m.] MMMM D [d.], ddd, HH:mm [val.]"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"YYYY [m.] MMMM D [d.]",LLL:"YYYY [m.] MMMM D [d.], HH:mm [val.]",LLLL:"YYYY [m.] MMMM D [d.], dddd, HH:mm [val.]",l:"YYYY-MM-DD",ll:"YYYY [m.] MMMM D [d.]",lll:"YYYY [m.] MMMM D [d.], HH:mm [val.]",llll:"YYYY [m.] MMMM D [d.], ddd, HH:mm [val.]"}};return e.default.locale(Y,null,!0),Y}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/58666.91b79adf.chunk.js b/ydb/core/viewer/monitoring/static/js/58666.91b79adf.chunk.js new file mode 100644 index 000000000000..32ea32a32021 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/58666.91b79adf.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[58666],{29309:a=>{function e(a){!function(a){a.languages.false={comment:{pattern:/\{[^}]*\}/},string:{pattern:/"[^"]*"/,greedy:!0},"character-code":{pattern:/'(?:[^\r]|\r\n?)/,alias:"number"},"assembler-code":{pattern:/\d+`/,alias:"important"},number:/\d+/,operator:/[-!#$%&'*+,./:;=>?@\\^_`|~\xdf\xf8]/,punctuation:/\[|\]/,variable:/[a-z]/,"non-standard":{pattern:/[(){t.d(e,{default:()=>r});var n=t(29309);const r=t.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5875.f8a190bf.chunk.js b/ydb/core/viewer/monitoring/static/js/5875.f8a190bf.chunk.js deleted file mode 100644 index 7e6298b22c2e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5875.f8a190bf.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5875],{98256:(e,t,C)=>{C.r(t),C.d(t,{ReactComponent:()=>u,default:()=>E});var r,a,n,o,i,l,s,d,c,H,p,V,k,M=C(59284);function h(){return h=Object.assign?Object.assign.bind():function(e){for(var t=1;t=1&&e%10<=4&&(e%100<10||e%100>=20)?e%10==1?a[0]:a[1]:a[2]},relativeTimeFormatter:function(e,a,t,d){var n=r.words[t];if(1===t.length)return"y"===t&&a?"jedna godina":d||a?n[0]:n[1];var i=r.correctGrammarCase(e,n);return"yy"===t&&a&&"%d godinu"===i?e+" godina":i.replace("%d",e)}},d={name:"sr",weekdays:"Nedelja_Ponedeljak_Utorak_Sreda_\u010cetvrtak_Petak_Subota".split("_"),weekdaysShort:"Ned._Pon._Uto._Sre._\u010cet._Pet._Sub.".split("_"),weekdaysMin:"ne_po_ut_sr_\u010de_pe_su".split("_"),months:"Januar_Februar_Mart_April_Maj_Jun_Jul_Avgust_Septembar_Oktobar_Novembar_Decembar".split("_"),monthsShort:"Jan._Feb._Mar._Apr._Maj_Jun_Jul_Avg._Sep._Okt._Nov._Dec.".split("_"),weekStart:1,relativeTime:{future:"za %s",past:"pre %s",s:"nekoliko sekundi",m:r.relativeTimeFormatter,mm:r.relativeTimeFormatter,h:r.relativeTimeFormatter,hh:r.relativeTimeFormatter,d:r.relativeTimeFormatter,dd:r.relativeTimeFormatter,M:r.relativeTimeFormatter,MM:r.relativeTimeFormatter,y:r.relativeTimeFormatter,yy:r.relativeTimeFormatter},ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"D. M. YYYY.",LL:"D. MMMM YYYY.",LLL:"D. MMMM YYYY. H:mm",LLLL:"dddd, D. MMMM YYYY. H:mm"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5888.4fa64369.chunk.js b/ydb/core/viewer/monitoring/static/js/5888.4fa64369.chunk.js deleted file mode 100644 index abe026a77681..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5888.4fa64369.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5888.4fa64369.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5888],{35888:(e,r,n)=>{n.r(r),n.d(r,{conf:()=>t,language:()=>s});var t={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#%\^\&\*\(\)\=\$\-\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{blockComment:["###","###"],lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*#region\\b"),end:new RegExp("^\\s*#endregion\\b")}}},s={defaultToken:"",ignoreCase:!0,tokenPostfix:".coffee",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],regEx:/\/(?!\/\/)(?:[^\/\\]|\\.)*\/[igm]*/,keywords:["and","or","is","isnt","not","on","yes","@","no","off","true","false","null","this","new","delete","typeof","in","instanceof","return","throw","break","continue","debugger","if","else","switch","for","while","do","try","catch","finally","class","extends","super","undefined","then","unless","until","loop","of","by","when"],symbols:/[=>12?"\u0645":"\u0635"},relativeTime:{future:"\u0628\u0639\u062f %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0627\u0646\u064a\u0629 \u0648\u0627\u062d\u062f\u0629",m:"\u062f\u0642\u064a\u0642\u0629 \u0648\u0627\u062d\u062f\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629 \u0648\u0627\u062d\u062f\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645 \u0648\u0627\u062d\u062f",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631 \u0648\u0627\u062d\u062f",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0639\u0627\u0645 \u0648\u0627\u062d\u062f",yy:"%d \u0623\u0639\u0648\u0627\u0645"},preparse:function(e){return e.replace(/[\u0661\u0662\u0663\u0664\u0665\u0666\u0667\u0668\u0669\u0660]/g,(function(e){return d[e]})).replace(/\u060c/g,",")},postformat:function(e){return e.replace(/\d/g,(function(e){return r[e]})).replace(/,/g,"\u060c")},ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"D/\u200fM/\u200fYYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"}};return _.default.locale(u,null,!0),u}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/58986.472d72cc.chunk.js b/ydb/core/viewer/monitoring/static/js/58986.472d72cc.chunk.js new file mode 100644 index 000000000000..36d40ee59467 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/58986.472d72cc.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 58986.472d72cc.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[58986],{58986:(e,t,r)=>{r.r(t),r.d(t,{conf:()=>h,language:()=>u});var o,i,n=r(80781),a=Object.defineProperty,m=Object.getOwnPropertyDescriptor,s=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,l=(e,t,r,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of s(t))c.call(e,i)||i===r||a(e,i,{get:()=>t[i],enumerable:!(o=m(t,i))||o.enumerable});return e},d={};l(d,o=n,"default"),i&&l(i,o,"default");var p=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],h={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,comments:{blockComment:["\x3c!--","--\x3e"]},brackets:[["\x3c!--","--\x3e"],["<",">"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"<",close:">"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/(\w[\w\d]*)\s*>$/i,action:{indentAction:d.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:d.languages.IndentAction.Indent}}]},u={defaultToken:"",tokenPostfix:"",tokenizer:{root:[[/@@@@/],[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.root"}],[/)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)(script)/,["delimiter.html",{token:"tag.html",next:"@script"}]],[/(<)(style)/,["delimiter.html",{token:"tag.html",next:"@style"}]],[/(<)([:\w\-]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)([\w\-]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/]+/,"metatag.content.html"],[/>/,"metatag.html","@pop"]],comment:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.comment"}],[/-->/,"comment.html","@pop"],[/[^-]+/,"comment.content.html"],[/./,"comment.content.html"]],otherTag:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.otherTag"}],[/\/?>/,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.script"}],[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],scriptAfterType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.scriptAfterType"}],[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.scriptAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.scriptWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInEmbeddedState.scriptEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],style:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.style"}],[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],styleAfterType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.styleAfterType"}],[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.styleAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.styleWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInEmbeddedState.styleEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],razorInSimpleState:[[/@\*/,"comment.cs","@razorBlockCommentTopLevel"],[/@[{(]/,"metatag.cs","@razorRootTopLevel"],[/(@)(\s*[\w]+)/,["metatag.cs",{token:"identifier.cs",switchTo:"@$S2.$S3"}]],[/[})]/,{token:"metatag.cs",switchTo:"@$S2.$S3"}],[/\*@/,{token:"comment.cs",switchTo:"@$S2.$S3"}]],razorInEmbeddedState:[[/@\*/,"comment.cs","@razorBlockCommentTopLevel"],[/@[{(]/,"metatag.cs","@razorRootTopLevel"],[/(@)(\s*[\w]+)/,["metatag.cs",{token:"identifier.cs",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}]],[/[})]/,{token:"metatag.cs",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}],[/\*@/,{token:"comment.cs",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}]],razorBlockCommentTopLevel:[[/\*@/,"@rematch","@pop"],[/[^*]+/,"comment.cs"],[/./,"comment.cs"]],razorBlockComment:[[/\*@/,"comment.cs","@pop"],[/[^*]+/,"comment.cs"],[/./,"comment.cs"]],razorRootTopLevel:[[/\{/,"delimiter.bracket.cs","@razorRoot"],[/\(/,"delimiter.parenthesis.cs","@razorRoot"],[/[})]/,"@rematch","@pop"],{include:"razorCommon"}],razorRoot:[[/\{/,"delimiter.bracket.cs","@razorRoot"],[/\(/,"delimiter.parenthesis.cs","@razorRoot"],[/\}/,"delimiter.bracket.cs","@pop"],[/\)/,"delimiter.parenthesis.cs","@pop"],{include:"razorCommon"}],razorCommon:[[/[a-zA-Z_]\w*/,{cases:{"@razorKeywords":{token:"keyword.cs"},"@default":"identifier.cs"}}],[/[\[\]]/,"delimiter.array.cs"],[/[ \t\r\n]+/],[/\/\/.*$/,"comment.cs"],[/@\*/,"comment.cs","@razorBlockComment"],[/"([^"]*)"/,"string.cs"],[/'([^']*)'/,"string.cs"],[/(<)([\w\-]+)(\/>)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)([\w\-]+)(>)/,["delimiter.html","tag.html","delimiter.html"]],[/(<\/)([\w\-]+)(>)/,["delimiter.html","tag.html","delimiter.html"]],[/[\+\-\*\%\&\|\^\~\!\=\<\>\/\?\;\:\.\,]/,"delimiter.cs"],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float.cs"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float.cs"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F]/,"number.hex.cs"],[/0[0-7']*[0-7]/,"number.octal.cs"],[/0[bB][0-1']*[0-1]/,"number.binary.cs"],[/\d[\d']*/,"number.cs"],[/\d/,"number.cs"]]},razorKeywords:["abstract","as","async","await","base","bool","break","by","byte","case","catch","char","checked","class","const","continue","decimal","default","delegate","do","double","descending","explicit","event","extern","else","enum","false","finally","fixed","float","for","foreach","from","goto","group","if","implicit","in","int","interface","internal","into","is","lock","long","nameof","new","null","namespace","object","operator","out","override","orderby","params","private","protected","public","readonly","ref","return","switch","struct","sbyte","sealed","short","sizeof","stackalloc","static","string","select","this","throw","true","try","typeof","uint","ulong","unchecked","unsafe","ushort","using","var","virtual","volatile","void","when","while","where","yield","model","inject"],escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6214.a9a481a7.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/58986.472d72cc.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6214.a9a481a7.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/58986.472d72cc.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/59172.d3dd36c7.chunk.js b/ydb/core/viewer/monitoring/static/js/59172.d3dd36c7.chunk.js new file mode 100644 index 000000000000..851863118c7b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/59172.d3dd36c7.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 59172.d3dd36c7.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[59172],{5874:(e,t,n)=>{n.d(t,{W:()=>L});var l=n(59284);const o=e=>{if(e.options.enableRowSelection)return Boolean(e.options.enableMultiRowSelection)};var r=n(32084);const i=l.createContext(void 0),a={};var s=n(85720);const u=e=>{const t=e.column.getIsPinned(),n="left"===t,l="right"===t,o=n&&e.column.getIsLastColumn("left"),r=l&&e.column.getIsFirstColumn("right");return{pinned:Boolean(t),"pinned-left":n,"pinned-right":l,"last-pinned-left":o,"first-pinned-right":r}},d=e=>e?Object.assign({id:e.column.id},u(e)):null,g=(e,t)=>{if(!e)return t;const n=e.column.getIsPinned();return Object.assign({width:e.column.getSize(),minWidth:e.column.columnDef.minSize,maxWidth:e.column.columnDef.maxSize,left:"left"===n?`${e.column.getStart("left")}px`:void 0,right:"right"===n?`${e.column.getAfter("right")}px`:void 0},t)};var c=n(82435);(0,c.withNaming)({e:"__",m:"_"});const p=(0,c.withNaming)({n:"gt-",e:"__",m:"_"}),m=p("table");var f=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{cell:t,children:n,className:o,style:r,attributes:i}=e,a=f(e,["cell","children","className","style","attributes"]);const u="function"===typeof i?i(t):i,c="function"===typeof o?o(t):o;return l.createElement("td",Object.assign({className:m("cell",d(t),c)},a,u,{style:g(t,Object.assign(Object.assign({},r),null===u||void 0===u?void 0:u.style))}),t?(0,s.Kv)(t.column.columnDef.cell,t.getContext()):n)},w=p("group-header"),h=({row:e,className:t,getGroupTitle:n})=>{var o;return l.createElement("h2",{className:w(null,t)},l.createElement("button",{className:w("button"),onClick:e.getToggleExpandedHandler()},l.createElement("svg",{className:w("icon",{expanded:e.getIsExpanded()}),viewBox:"0 0 16 16",width:"16",height:"16"},l.createElement("path",{d:"M2.97 5.47a.75.75 0 0 1 1.06 0L8 9.44l3.97-3.97a.75.75 0 1 1 1.06 1.06l-4.5 4.5a.75.75 0 0 1-1.06 0l-4.5-4.5a.75.75 0 0 1 0-1.06Z",fill:"currentColor"})),l.createElement("span",{className:w("content")},l.createElement("span",{className:w("title")},null!==(o=null===n||void 0===n?void 0:n(e))&&void 0!==o?o:e.id),l.createElement("span",{className:w("total")},e.subRows.length))))};var b=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{cellClassName:n,className:o,getGroupTitle:i,getIsCustomRow:a,getIsGroupHeaderRow:s,groupHeaderClassName:u,onClick:d,renderCustomRowContent:g,renderGroupHeader:c,renderGroupHeaderRowContent:p,row:f,rowVirtualizer:w,style:C,virtualItem:S,attributes:R,cellAttributes:y,table:I}=e,x=b(e,["cellClassName","className","getGroupTitle","getIsCustomRow","getIsGroupHeaderRow","groupHeaderClassName","onClick","renderCustomRowContent","renderGroupHeader","renderGroupHeaderRowContent","row","rowVirtualizer","style","virtualItem","attributes","cellAttributes","table"]);const M=(0,r.N)(null===w||void 0===w?void 0:w.measureElement,t),F="function"===typeof R?R(f):R,P="function"===typeof o?o(f):o,E=l.useCallback((e=>{null===d||void 0===d||d(f,e)}),[d,f]);return l.createElement("tr",Object.assign({ref:M,className:m("row",{selected:f.getIsSelected(),interactive:Boolean(d)},P),onClick:E,"data-index":null===S||void 0===S?void 0:S.index},x,F,{style:Object.assign(Object.assign({top:w&&S?S.start-w.options.scrollMargin:void 0},C),null===F||void 0===F?void 0:F.style)}),(null===s||void 0===s?void 0:s(f))?p?p({row:f,Cell:v,cellClassName:n,getGroupTitle:i}):l.createElement(v,{className:n,colSpan:f.getVisibleCells().length,attributes:y,"aria-colindex":1},c?c({row:f,className:m("group-header",u),getGroupTitle:i}):l.createElement(h,{row:f,className:m("group-header",u),getGroupTitle:i})):(null===a||void 0===a?void 0:a(f))&&g?g({row:f,Cell:v,cellClassName:n}):f.getVisibleCells().map((e=>l.createElement(v,{key:e.id,cell:e,className:n,attributes:y,"aria-colindex":e.column.getIndex()+1}))))}));C.displayName="BaseRow";var S=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var n,{attributes:o,row:s,style:u,table:d}=e,g=S(e,["attributes","row","style","table"]);const{isChildMode:c,activeItemKey:p,targetItemIndex:m=-1,enableNesting:f,useSortable:v}=null!==(n=l.useContext(i))&&void 0!==n?n:{},{setNodeRef:w,transform:h=null,transition:b,isDragging:R=!1}=(null===v||void 0===v?void 0:v({id:s.id}))||{},y=Boolean(p),I=c&&m===s.index,x=(0,r.N)(w,t),{isFirstChild:M,depth:F}=(({row:e,table:t,isDragging:n})=>{var o,r,a,s,u;const{isChildMode:d,isParentMode:g,isNextChildMode:c,targetItemIndex:p=-1,enableNesting:m}=null!==(o=l.useContext(i))&&void 0!==o?o:{};let f=n&&-1===p,v=0;if(m)if(n&&-1!==p){const e=t.getRowModel().rows,n=null!==(a=null===(r=e[p])||void 0===r?void 0:r.depth)&&void 0!==a?a:0,l=null!==(u=null===(s=e[p+1])||void 0===s?void 0:s.depth)&&void 0!==u?u:0;if(f=l>n,f)v=l,g&&v--;else{let e=0;g?e=-1:d&&(e=1),v=(c?n:Math.min(n,l))+e}v=Math.max(0,v)}else v=f?0:e.depth;return{depth:v,isFirstChild:f}})({row:s,table:d,isDragging:R}),P=(({style:e=a,transform:t,transition:n,isDragging:o,isDragActive:r,isFirstChild:s,draggableChildRowOffset:u=32,enableNesting:d})=>{var g;const{isChildMode:c,isParentMode:p}=null!==(g=l.useContext(i))&&void 0!==g?g:{};return l.useMemo((()=>{if(!r||!t)return e;let l=0;return d&&o&&(p?l=-u:c&&!s&&(l=u)),Object.assign(Object.assign({},e),{transition:n,transform:`translate3d(${Math.max(l,0)}px, ${t.y}px, 0)`})}),[u,c,r,o,s,p,e,t,n,d])})({style:u,transform:h,transition:b,isDragging:R,isDragActive:y,isFirstChild:M,enableNesting:f}),E=l.useCallback((e=>{const t="function"===typeof o?o(e):o;return Object.assign(Object.assign({},t),{"data-key":e.id,"data-depth":F,"data-draggable":!0,"data-dragging":R,"data-drag-active":y,"data-expanded":y&&I})}),[o,F,R,y,I]);return l.createElement(C,Object.assign({ref:x,attributes:E,row:s,style:P,table:d},g))}));R.displayName="BaseDraggableRow";const y=e=>Object.assign({id:e.column.id,placeholder:e.isPlaceholder,sortable:e.column.getCanSort(),wide:e.colSpan>1},u(e)),I=({header:e,attributes:t,className:n})=>{const o="function"===typeof t?t(e):t,r="function"===typeof n?n(e):n,i=e.depth-e.column.depth;return l.createElement("th",Object.assign({className:m("footer-cell",y(e),r),colSpan:e.colSpan>1?e.colSpan:void 0,rowSpan:i>1?i:void 0},o,{style:g(e,null===o||void 0===o?void 0:o.style)}),(0,s.Kv)(e.column.columnDef.footer,e.getContext()))};var x=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{footerGroup:t,attributes:n,cellAttributes:o,cellClassName:r,className:i}=e,a=x(e,["footerGroup","attributes","cellAttributes","cellClassName","className"]);const s="function"===typeof n?n(t):n,u="function"===typeof i?i(t):i;return l.createElement("tr",Object.assign({className:m("footer-row",u)},a,s),t.headers.map((e=>(e=>!e.isPlaceholder)(e)?l.createElement(I,{key:e.column.id,header:e,attributes:o,className:r}):null)))},F=e=>{if(e)return"asc"===e?"ascending":"descending"},P=e=>e.headerGroup.headers.slice(0,e.index).reduce(((e,t)=>e+t.colSpan),1),E=p("resize-handle"),V=({className:e,header:t})=>{var n;const{table:o}=t.getContext(),{columnResizeDirection:r,columnResizeMode:i}=o.options,{columnSizingInfo:a}=o.getState(),s=("rtl"===r?-1:1)*(null!==(n=a.deltaOffset)&&void 0!==n?n:0);return l.createElement("div",{className:E({direction:r,resizing:t.column.getIsResizing()},e),onDoubleClick:()=>t.column.resetSize(),onMouseDown:t.getResizeHandler(),onTouchStart:t.getResizeHandler(),style:{transform:"onEnd"===i&&t.column.getIsResizing()?`translateX(${s}px)`:void 0}})};var O=n(46734),_=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{header:t,className:n,children:o}=e,r=_(e,["header","className","children"]);const i=t.column.getToggleSortingHandler(),{onKeyDown:a}=(0,O.N)(i);return l.createElement("span",Object.assign({className:m("sort",n),role:"button",tabIndex:0,onClick:i,onKeyDown:a},r),o)},G=p("sort-indicator"),N=({className:e,header:t})=>{const n=t.column.getIsSorted();return l.createElement("span",{className:G({order:n,invisible:!n},e)},l.createElement("svg",{width:"6",height:"3",viewBox:"0 0 6 3",fill:"currentColor"},l.createElement("path",{d:"M0.404698 0C0.223319 0 0.102399 0.0887574 0.0419396 0.230769C-0.0386733 0.372781 0.00163315 0.497041 0.122552 0.60355L2.72232 2.89349C2.80293 2.9645 2.88354 3 3.00446 3C3.10523 3 3.20599 2.9645 3.28661 2.89349L5.88637 0.60355C6.00729 0.497041 6.02745 0.372781 5.96699 0.230769C5.88637 0.0887574 5.76545 0 5.60423 0H0.404698Z"})))},H=({className:e,header:t,parentHeader:n,renderHeaderCellContent:o,renderResizeHandle:r,renderSortIndicator:i,resizeHandleClassName:a,sortIndicatorClassName:u,attributes:d})=>{const c="function"===typeof d?d(t,n):d,p="function"===typeof e?e(t,n):e,f=t.isPlaceholder?t.getLeafHeaders().length:1;return l.createElement("th",Object.assign({className:m("header-cell",y(t),p),colSpan:t.colSpan>1?t.colSpan:void 0,rowSpan:f>1?f:void 0,"aria-sort":F(t.column.getIsSorted()),"aria-colindex":P(t)},c,{style:g(t,null===c||void 0===c?void 0:c.style)}),o?o({header:t}):l.createElement(l.Fragment,null,t.column.getCanSort()?l.createElement(z,{header:t},(0,s.Kv)(t.column.columnDef.header,t.getContext())," ",i?i({className:m("sort-indicator",u),header:t}):l.createElement(N,{className:m("sort-indicator",u),header:t})):(0,s.Kv)(t.column.columnDef.header,t.getContext()),t.column.getCanResize()&&(r?r({className:m("resize-handle",a),header:t}):l.createElement(V,{className:m("resize-handle",a),header:t}))))};var A=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{cellClassName:t,className:n,headerGroup:o,parentHeaderGroup:r,renderHeaderCellContent:i,renderResizeHandle:a,renderSortIndicator:s,resizeHandleClassName:u,sortIndicatorClassName:d,attributes:g,cellAttributes:c}=e,p=A(e,["cellClassName","className","headerGroup","parentHeaderGroup","renderHeaderCellContent","renderResizeHandle","renderSortIndicator","resizeHandleClassName","sortIndicatorClassName","attributes","cellAttributes"]);const f="function"===typeof g?g(o,r):g,v="function"===typeof n?n(o,r):n;return l.createElement("tr",Object.assign({className:m("header-row",v)},p,f),o.headers.map((e=>{const n=null===r||void 0===r?void 0:r.headers.find((t=>e.column.id===t.column.id));return((e,t)=>{const n=e.isPlaceholder&&(null===t||void 0===t?void 0:t.isPlaceholder)&&t.placeholderId===e.placeholderId,l=!e.isPlaceholder&&e.id===e.column.id&&e.depth-e.column.depth>1;return!(n||l)})(e,n)?l.createElement(H,{key:e.column.id,className:t,header:e,parentHeader:n,renderHeaderCellContent:i,renderResizeHandle:a,renderSortIndicator:s,resizeHandleClassName:u,sortIndicatorClassName:d,attributes:c}):null})))},L=l.forwardRef((({table:e,attributes:t,bodyAttributes:n,bodyClassName:r,bodyRef:a,cellAttributes:s,cellClassName:u,className:d,customFooterRowCount:g,emptyContent:c,footerAttributes:p,footerCellAttributes:f,footerCellClassName:v,footerClassName:w,footerRowAttributes:h,footerRowClassName:b,getGroupTitle:S,getIsCustomRow:y,getIsGroupHeaderRow:I,groupHeaderClassName:x,headerAttributes:F,headerCellAttributes:P,headerCellClassName:E,headerClassName:V,headerRowAttributes:O,headerRowClassName:_,onRowClick:z,renderCustomFooterContent:G,renderCustomRowContent:N,renderGroupHeader:H,renderGroupHeaderRowContent:A,renderHeaderCellContent:L,renderResizeHandle:j,renderSortIndicator:T,resizeHandleClassName:k,rowAttributes:B,rowClassName:q,rowVirtualizer:$,sortIndicatorClassName:U,stickyFooter:K=!1,stickyHeader:X=!1,withFooter:Z=!1,withHeader:W=!0},J)=>{var Q;const Y=l.useContext(i),ee=null!==(Q=null===Y||void 0===Y?void 0:Y.activeItemIndex)&&void 0!==Q?Q:-1,{rows:te,rowsById:ne}=e.getRowModel(),le=l.useMemo((()=>(e=>{let t=1;return e.reduce(((e,n,l,o)=>{const r=Object.assign(Object.assign({},e),{[n.id]:t}),i=o[l+1];return(null===i||void 0===i?void 0:i.parentId)!==n.id&&(t+=n.getLeafRows().length),t++,r}),{})})(te)),[te]),oe=W?e.getHeaderGroups():[],re=Z?e.getFooterGroups():[],ie=e.getVisibleLeafColumns().length,ae=oe.length,se=Object.keys(ne).length,ue=Z&&(G&&g||re.length)||0,de=se+ae+ue,ge=(null===$||void 0===$?void 0:$.getVirtualItems())||te;return l.createElement("table",Object.assign({ref:J,className:m({"with-row-virtualization":Boolean($)},d),"data-dragging-row-index":ee>-1?ee:void 0,"aria-colcount":ie>0?ie:void 0,"aria-rowcount":de>0?de:void 0,"aria-multiselectable":o(e)},t),W&&l.createElement("thead",Object.assign({className:m("header",{sticky:X},V)},F),oe.map(((e,t)=>l.createElement(D,{key:e.id,cellClassName:E,className:_,headerGroup:e,parentHeaderGroup:oe[t-1],renderHeaderCellContent:L,renderResizeHandle:j,renderSortIndicator:T,resizeHandleClassName:k,sortIndicatorClassName:U,attributes:O,cellAttributes:P,"aria-rowindex":t+1})))),l.createElement("tbody",Object.assign({ref:a,className:m("body",r)},n,{style:Object.assign({height:ge.length?null===$||void 0===$?void 0:$.getTotalSize():void 0},null===n||void 0===n?void 0:n.style)}),ge.length?ge.map((t=>{var n;const o=$?te[t.index]:t,r=$?t:void 0,i=null!==(n=null===r||void 0===r?void 0:r.key)&&void 0!==n?n:o.id,a={cellClassName:u,className:q,getGroupTitle:S,getIsCustomRow:y,getIsGroupHeaderRow:I,groupHeaderClassName:x,attributes:B,cellAttributes:s,onClick:z,renderCustomRowContent:N,renderGroupHeader:H,renderGroupHeaderRowContent:A,row:o,rowVirtualizer:$,table:e,virtualItem:r,"aria-rowindex":ae+le[o.id],"aria-selected":e.options.enableRowSelection?o.getIsSelected():void 0};return Y?l.createElement(R,Object.assign({key:i},a)):l.createElement(C,Object.assign({key:i},a))})):(()=>{if(!c)return null;const t="function"===typeof q?q():q,n="function"===typeof u?u():u;return l.createElement("tr",{className:m("row",{empty:!0},t)},l.createElement("td",{className:m("cell",{},n),colSpan:ie,style:{width:$?e.getTotalSize():void 0}},"function"===typeof c?c():c))})()),Z&&l.createElement("tfoot",Object.assign({className:m("footer",{sticky:K},w)},p),G?G({cellClassName:m("footer-cell"),footerGroups:re,rowClassName:m("footer-row"),rowIndex:ae+se+1}):re.map(((e,t)=>(e=>e.headers.some((e=>e.column.columnDef.footer)))(e)?l.createElement(M,{key:e.id,footerGroup:e,attributes:h,cellAttributes:f,cellClassName:v,className:b,"aria-rowindex":ae+se+t+1}):null))))}));L.displayName="BaseTable"},18677:(e,t,n)=>{n.d(t,{A:()=>o});var l=n(59284);const o=e=>l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),l.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},24953:(e,t,n)=>{function l(e,t){return"function"===typeof e?e(t):e}function o(e,t){return n=>{t.setState((t=>({...t,[e]:l(n,t[e])})))}}function r(e){return e instanceof Function}function i(e,t){const n=[],l=e=>{e.forEach((e=>{n.push(e);const o=t(e);null!=o&&o.length&&l(o)}))};return l(e),n}function a(e,t,n){let l,o=[];return r=>{let i;n.key&&n.debug&&(i=Date.now());const a=e(r);if(!(a.length!==o.length||a.some(((e,t)=>o[t]!==e))))return l;let s;if(o=a,n.key&&n.debug&&(s=Date.now()),l=t(...a),null==n||null==n.onChange||n.onChange(l),n.key&&n.debug&&null!=n&&n.debug()){const e=Math.round(100*(Date.now()-i))/100,t=Math.round(100*(Date.now()-s))/100,l=t/16,o=(e,t)=>{for(e=String(e);e.length{var n;return null!=(n=null==e?void 0:e.debugAll)?n:e[t]},key:!1,onChange:l}}n.d(t,{D0:()=>W,HT:()=>Z,ZR:()=>X,cU:()=>Q,h5:()=>Y});const u="debugHeaders";function d(e,t,n){var l;let o={id:null!=(l=n.id)?l:t.id,column:t,index:n.index,isPlaceholder:!!n.isPlaceholder,placeholderId:n.placeholderId,depth:n.depth,subHeaders:[],colSpan:0,rowSpan:0,headerGroup:null,getLeafHeaders:()=>{const e=[],t=n=>{n.subHeaders&&n.subHeaders.length&&n.subHeaders.map(t),e.push(n)};return t(o),e},getContext:()=>({table:e,header:o,column:t})};return e._features.forEach((t=>{null==t.createHeader||t.createHeader(o,e)})),o}const g={createTable:e=>{e.getHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.left,e.getState().columnPinning.right]),((t,n,l,o)=>{var r,i;const a=null!=(r=null==l?void 0:l.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?r:[],s=null!=(i=null==o?void 0:o.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?i:[];return c(t,[...a,...n.filter((e=>!(null!=l&&l.includes(e.id))&&!(null!=o&&o.includes(e.id)))),...s],e)}),s(e.options,u)),e.getCenterHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.left,e.getState().columnPinning.right]),((t,n,l,o)=>c(t,n=n.filter((e=>!(null!=l&&l.includes(e.id))&&!(null!=o&&o.includes(e.id)))),e,"center")),s(e.options,u)),e.getLeftHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.left]),((t,n,l)=>{var o;return c(t,null!=(o=null==l?void 0:l.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?o:[],e,"left")}),s(e.options,u)),e.getRightHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.right]),((t,n,l)=>{var o;return c(t,null!=(o=null==l?void 0:l.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?o:[],e,"right")}),s(e.options,u)),e.getFooterGroups=a((()=>[e.getHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getLeftFooterGroups=a((()=>[e.getLeftHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getCenterFooterGroups=a((()=>[e.getCenterHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getRightFooterGroups=a((()=>[e.getRightHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getFlatHeaders=a((()=>[e.getHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getLeftFlatHeaders=a((()=>[e.getLeftHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getCenterFlatHeaders=a((()=>[e.getCenterHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getRightFlatHeaders=a((()=>[e.getRightHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getCenterLeafHeaders=a((()=>[e.getCenterFlatHeaders()]),(e=>e.filter((e=>{var t;return!(null!=(t=e.subHeaders)&&t.length)}))),s(e.options,u)),e.getLeftLeafHeaders=a((()=>[e.getLeftFlatHeaders()]),(e=>e.filter((e=>{var t;return!(null!=(t=e.subHeaders)&&t.length)}))),s(e.options,u)),e.getRightLeafHeaders=a((()=>[e.getRightFlatHeaders()]),(e=>e.filter((e=>{var t;return!(null!=(t=e.subHeaders)&&t.length)}))),s(e.options,u)),e.getLeafHeaders=a((()=>[e.getLeftHeaderGroups(),e.getCenterHeaderGroups(),e.getRightHeaderGroups()]),((e,t,n)=>{var l,o,r,i,a,s;return[...null!=(l=null==(o=e[0])?void 0:o.headers)?l:[],...null!=(r=null==(i=t[0])?void 0:i.headers)?r:[],...null!=(a=null==(s=n[0])?void 0:s.headers)?a:[]].map((e=>e.getLeafHeaders())).flat()}),s(e.options,u))}};function c(e,t,n,l){var o,r;let i=0;const a=function(e,t){void 0===t&&(t=1),i=Math.max(i,t),e.filter((e=>e.getIsVisible())).forEach((e=>{var n;null!=(n=e.columns)&&n.length&&a(e.columns,t+1)}),0)};a(e);let s=[];const u=(e,t)=>{const o={depth:t,id:[l,`${t}`].filter(Boolean).join("_"),headers:[]},r=[];e.forEach((e=>{const i=[...r].reverse()[0];let a,s=!1;if(e.column.depth===o.depth&&e.column.parent?a=e.column.parent:(a=e.column,s=!0),i&&(null==i?void 0:i.column)===a)i.subHeaders.push(e);else{const o=d(n,a,{id:[l,t,a.id,null==e?void 0:e.id].filter(Boolean).join("_"),isPlaceholder:s,placeholderId:s?`${r.filter((e=>e.column===a)).length}`:void 0,depth:t,index:r.length});o.subHeaders.push(e),r.push(o)}o.headers.push(e),e.headerGroup=o})),s.push(o),t>0&&u(r,t-1)},g=t.map(((e,t)=>d(n,e,{depth:i,index:t})));u(g,i-1),s.reverse();const c=e=>e.filter((e=>e.column.getIsVisible())).map((e=>{let t=0,n=0,l=[0];e.subHeaders&&e.subHeaders.length?(l=[],c(e.subHeaders).forEach((e=>{let{colSpan:n,rowSpan:o}=e;t+=n,l.push(o)}))):t=1;return n+=Math.min(...l),e.colSpan=t,e.rowSpan=n,{colSpan:t,rowSpan:n}}));return c(null!=(o=null==(r=s[0])?void 0:r.headers)?o:[]),s}const p=(e,t,n,l,o,r,u)=>{let d={id:t,index:l,original:n,depth:o,parentId:u,_valuesCache:{},_uniqueValuesCache:{},getValue:t=>{if(d._valuesCache.hasOwnProperty(t))return d._valuesCache[t];const n=e.getColumn(t);return null!=n&&n.accessorFn?(d._valuesCache[t]=n.accessorFn(d.original,l),d._valuesCache[t]):void 0},getUniqueValues:t=>{if(d._uniqueValuesCache.hasOwnProperty(t))return d._uniqueValuesCache[t];const n=e.getColumn(t);return null!=n&&n.accessorFn?n.columnDef.getUniqueValues?(d._uniqueValuesCache[t]=n.columnDef.getUniqueValues(d.original,l),d._uniqueValuesCache[t]):(d._uniqueValuesCache[t]=[d.getValue(t)],d._uniqueValuesCache[t]):void 0},renderValue:t=>{var n;return null!=(n=d.getValue(t))?n:e.options.renderFallbackValue},subRows:null!=r?r:[],getLeafRows:()=>i(d.subRows,(e=>e.subRows)),getParentRow:()=>d.parentId?e.getRow(d.parentId,!0):void 0,getParentRows:()=>{let e=[],t=d;for(;;){const n=t.getParentRow();if(!n)break;e.push(n),t=n}return e.reverse()},getAllCells:a((()=>[e.getAllLeafColumns()]),(t=>t.map((t=>function(e,t,n,l){const o={id:`${t.id}_${n.id}`,row:t,column:n,getValue:()=>t.getValue(l),renderValue:()=>{var t;return null!=(t=o.getValue())?t:e.options.renderFallbackValue},getContext:a((()=>[e,n,t,o]),((e,t,n,l)=>({table:e,column:t,row:n,cell:l,getValue:l.getValue,renderValue:l.renderValue})),s(e.options,"debugCells"))};return e._features.forEach((l=>{null==l.createCell||l.createCell(o,n,t,e)}),{}),o}(e,d,t,t.id)))),s(e.options,"debugRows")),_getAllCellsByColumnId:a((()=>[d.getAllCells()]),(e=>e.reduce(((e,t)=>(e[t.column.id]=t,e)),{})),s(e.options,"debugRows"))};for(let i=0;i{e._getFacetedRowModel=t.options.getFacetedRowModel&&t.options.getFacetedRowModel(t,e.id),e.getFacetedRowModel=()=>e._getFacetedRowModel?e._getFacetedRowModel():t.getPreFilteredRowModel(),e._getFacetedUniqueValues=t.options.getFacetedUniqueValues&&t.options.getFacetedUniqueValues(t,e.id),e.getFacetedUniqueValues=()=>e._getFacetedUniqueValues?e._getFacetedUniqueValues():new Map,e._getFacetedMinMaxValues=t.options.getFacetedMinMaxValues&&t.options.getFacetedMinMaxValues(t,e.id),e.getFacetedMinMaxValues=()=>{if(e._getFacetedMinMaxValues)return e._getFacetedMinMaxValues()}}},f=(e,t,n)=>{var l,o;const r=null==n||null==(l=n.toString())?void 0:l.toLowerCase();return Boolean(null==(o=e.getValue(t))||null==(o=o.toString())||null==(o=o.toLowerCase())?void 0:o.includes(r))};f.autoRemove=e=>x(e);const v=(e,t,n)=>{var l;return Boolean(null==(l=e.getValue(t))||null==(l=l.toString())?void 0:l.includes(n))};v.autoRemove=e=>x(e);const w=(e,t,n)=>{var l;return(null==(l=e.getValue(t))||null==(l=l.toString())?void 0:l.toLowerCase())===(null==n?void 0:n.toLowerCase())};w.autoRemove=e=>x(e);const h=(e,t,n)=>{var l;return null==(l=e.getValue(t))?void 0:l.includes(n)};h.autoRemove=e=>x(e)||!(null!=e&&e.length);const b=(e,t,n)=>!n.some((n=>{var l;return!(null!=(l=e.getValue(t))&&l.includes(n))}));b.autoRemove=e=>x(e)||!(null!=e&&e.length);const C=(e,t,n)=>n.some((n=>{var l;return null==(l=e.getValue(t))?void 0:l.includes(n)}));C.autoRemove=e=>x(e)||!(null!=e&&e.length);const S=(e,t,n)=>e.getValue(t)===n;S.autoRemove=e=>x(e);const R=(e,t,n)=>e.getValue(t)==n;R.autoRemove=e=>x(e);const y=(e,t,n)=>{let[l,o]=n;const r=e.getValue(t);return r>=l&&r<=o};y.resolveFilterValue=e=>{let[t,n]=e,l="number"!==typeof t?parseFloat(t):t,o="number"!==typeof n?parseFloat(n):n,r=null===t||Number.isNaN(l)?-1/0:l,i=null===n||Number.isNaN(o)?1/0:o;if(r>i){const e=r;r=i,i=e}return[r,i]},y.autoRemove=e=>x(e)||x(e[0])&&x(e[1]);const I={includesString:f,includesStringSensitive:v,equalsString:w,arrIncludes:h,arrIncludesAll:b,arrIncludesSome:C,equals:S,weakEquals:R,inNumberRange:y};function x(e){return void 0===e||null===e||""===e}const M={getDefaultColumnDef:()=>({filterFn:"auto"}),getInitialState:e=>({columnFilters:[],...e}),getDefaultOptions:e=>({onColumnFiltersChange:o("columnFilters",e),filterFromLeafRows:!1,maxLeafRowFilterDepth:100}),createColumn:(e,t)=>{e.getAutoFilterFn=()=>{const n=t.getCoreRowModel().flatRows[0],l=null==n?void 0:n.getValue(e.id);return"string"===typeof l?I.includesString:"number"===typeof l?I.inNumberRange:"boolean"===typeof l||null!==l&&"object"===typeof l?I.equals:Array.isArray(l)?I.arrIncludes:I.weakEquals},e.getFilterFn=()=>{var n,l;return r(e.columnDef.filterFn)?e.columnDef.filterFn:"auto"===e.columnDef.filterFn?e.getAutoFilterFn():null!=(n=null==(l=t.options.filterFns)?void 0:l[e.columnDef.filterFn])?n:I[e.columnDef.filterFn]},e.getCanFilter=()=>{var n,l,o;return(null==(n=e.columnDef.enableColumnFilter)||n)&&(null==(l=t.options.enableColumnFilters)||l)&&(null==(o=t.options.enableFilters)||o)&&!!e.accessorFn},e.getIsFiltered=()=>e.getFilterIndex()>-1,e.getFilterValue=()=>{var n;return null==(n=t.getState().columnFilters)||null==(n=n.find((t=>t.id===e.id)))?void 0:n.value},e.getFilterIndex=()=>{var n,l;return null!=(n=null==(l=t.getState().columnFilters)?void 0:l.findIndex((t=>t.id===e.id)))?n:-1},e.setFilterValue=n=>{t.setColumnFilters((t=>{const o=e.getFilterFn(),r=null==t?void 0:t.find((t=>t.id===e.id)),i=l(n,r?r.value:void 0);var a;if(F(o,i,e))return null!=(a=null==t?void 0:t.filter((t=>t.id!==e.id)))?a:[];const s={id:e.id,value:i};var u;return r?null!=(u=null==t?void 0:t.map((t=>t.id===e.id?s:t)))?u:[]:null!=t&&t.length?[...t,s]:[s]}))}},createRow:(e,t)=>{e.columnFilters={},e.columnFiltersMeta={}},createTable:e=>{e.setColumnFilters=t=>{const n=e.getAllLeafColumns();null==e.options.onColumnFiltersChange||e.options.onColumnFiltersChange((e=>{var o;return null==(o=l(t,e))?void 0:o.filter((e=>{const t=n.find((t=>t.id===e.id));if(t){if(F(t.getFilterFn(),e.value,t))return!1}return!0}))}))},e.resetColumnFilters=t=>{var n,l;e.setColumnFilters(t?[]:null!=(n=null==(l=e.initialState)?void 0:l.columnFilters)?n:[])},e.getPreFilteredRowModel=()=>e.getCoreRowModel(),e.getFilteredRowModel=()=>(!e._getFilteredRowModel&&e.options.getFilteredRowModel&&(e._getFilteredRowModel=e.options.getFilteredRowModel(e)),e.options.manualFiltering||!e._getFilteredRowModel?e.getPreFilteredRowModel():e._getFilteredRowModel())}};function F(e,t,n){return!(!e||!e.autoRemove)&&e.autoRemove(t,n)||"undefined"===typeof t||"string"===typeof t&&!t}const P={sum:(e,t,n)=>n.reduce(((t,n)=>{const l=n.getValue(e);return t+("number"===typeof l?l:0)}),0),min:(e,t,n)=>{let l;return n.forEach((t=>{const n=t.getValue(e);null!=n&&(l>n||void 0===l&&n>=n)&&(l=n)})),l},max:(e,t,n)=>{let l;return n.forEach((t=>{const n=t.getValue(e);null!=n&&(l=n)&&(l=n)})),l},extent:(e,t,n)=>{let l,o;return n.forEach((t=>{const n=t.getValue(e);null!=n&&(void 0===l?n>=n&&(l=o=n):(l>n&&(l=n),o{let n=0,l=0;if(t.forEach((t=>{let o=t.getValue(e);null!=o&&(o=+o)>=o&&(++n,l+=o)})),n)return l/n},median:(e,t)=>{if(!t.length)return;const n=t.map((t=>t.getValue(e)));if(l=n,!Array.isArray(l)||!l.every((e=>"number"===typeof e)))return;var l;if(1===n.length)return n[0];const o=Math.floor(n.length/2),r=n.sort(((e,t)=>e-t));return n.length%2!==0?r[o]:(r[o-1]+r[o])/2},unique:(e,t)=>Array.from(new Set(t.map((t=>t.getValue(e)))).values()),uniqueCount:(e,t)=>new Set(t.map((t=>t.getValue(e)))).size,count:(e,t)=>t.length},E={getDefaultColumnDef:()=>({aggregatedCell:e=>{var t,n;return null!=(t=null==(n=e.getValue())||null==n.toString?void 0:n.toString())?t:null},aggregationFn:"auto"}),getInitialState:e=>({grouping:[],...e}),getDefaultOptions:e=>({onGroupingChange:o("grouping",e),groupedColumnMode:"reorder"}),createColumn:(e,t)=>{e.toggleGrouping=()=>{t.setGrouping((t=>null!=t&&t.includes(e.id)?t.filter((t=>t!==e.id)):[...null!=t?t:[],e.id]))},e.getCanGroup=()=>{var n,l;return(null==(n=e.columnDef.enableGrouping)||n)&&(null==(l=t.options.enableGrouping)||l)&&(!!e.accessorFn||!!e.columnDef.getGroupingValue)},e.getIsGrouped=()=>{var n;return null==(n=t.getState().grouping)?void 0:n.includes(e.id)},e.getGroupedIndex=()=>{var n;return null==(n=t.getState().grouping)?void 0:n.indexOf(e.id)},e.getToggleGroupingHandler=()=>{const t=e.getCanGroup();return()=>{t&&e.toggleGrouping()}},e.getAutoAggregationFn=()=>{const n=t.getCoreRowModel().flatRows[0],l=null==n?void 0:n.getValue(e.id);return"number"===typeof l?P.sum:"[object Date]"===Object.prototype.toString.call(l)?P.extent:void 0},e.getAggregationFn=()=>{var n,l;if(!e)throw new Error;return r(e.columnDef.aggregationFn)?e.columnDef.aggregationFn:"auto"===e.columnDef.aggregationFn?e.getAutoAggregationFn():null!=(n=null==(l=t.options.aggregationFns)?void 0:l[e.columnDef.aggregationFn])?n:P[e.columnDef.aggregationFn]}},createTable:e=>{e.setGrouping=t=>null==e.options.onGroupingChange?void 0:e.options.onGroupingChange(t),e.resetGrouping=t=>{var n,l;e.setGrouping(t?[]:null!=(n=null==(l=e.initialState)?void 0:l.grouping)?n:[])},e.getPreGroupedRowModel=()=>e.getFilteredRowModel(),e.getGroupedRowModel=()=>(!e._getGroupedRowModel&&e.options.getGroupedRowModel&&(e._getGroupedRowModel=e.options.getGroupedRowModel(e)),e.options.manualGrouping||!e._getGroupedRowModel?e.getPreGroupedRowModel():e._getGroupedRowModel())},createRow:(e,t)=>{e.getIsGrouped=()=>!!e.groupingColumnId,e.getGroupingValue=n=>{if(e._groupingValuesCache.hasOwnProperty(n))return e._groupingValuesCache[n];const l=t.getColumn(n);return null!=l&&l.columnDef.getGroupingValue?(e._groupingValuesCache[n]=l.columnDef.getGroupingValue(e.original),e._groupingValuesCache[n]):e.getValue(n)},e._groupingValuesCache={}},createCell:(e,t,n,l)=>{e.getIsGrouped=()=>t.getIsGrouped()&&t.id===n.groupingColumnId,e.getIsPlaceholder=()=>!e.getIsGrouped()&&t.getIsGrouped(),e.getIsAggregated=()=>{var t;return!e.getIsGrouped()&&!e.getIsPlaceholder()&&!(null==(t=n.subRows)||!t.length)}}};const V={getInitialState:e=>({columnOrder:[],...e}),getDefaultOptions:e=>({onColumnOrderChange:o("columnOrder",e)}),createColumn:(e,t)=>{e.getIndex=a((e=>[H(t,e)]),(t=>t.findIndex((t=>t.id===e.id))),s(t.options,"debugColumns")),e.getIsFirstColumn=n=>{var l;return(null==(l=H(t,n)[0])?void 0:l.id)===e.id},e.getIsLastColumn=n=>{var l;const o=H(t,n);return(null==(l=o[o.length-1])?void 0:l.id)===e.id}},createTable:e=>{e.setColumnOrder=t=>null==e.options.onColumnOrderChange?void 0:e.options.onColumnOrderChange(t),e.resetColumnOrder=t=>{var n;e.setColumnOrder(t?[]:null!=(n=e.initialState.columnOrder)?n:[])},e._getOrderColumnsFn=a((()=>[e.getState().columnOrder,e.getState().grouping,e.options.groupedColumnMode]),((e,t,n)=>l=>{let o=[];if(null!=e&&e.length){const t=[...e],n=[...l];for(;n.length&&t.length;){const e=t.shift(),l=n.findIndex((t=>t.id===e));l>-1&&o.push(n.splice(l,1)[0])}o=[...o,...n]}else o=l;return function(e,t,n){if(null==t||!t.length||!n)return e;const l=e.filter((e=>!t.includes(e.id)));return"remove"===n?l:[...t.map((t=>e.find((e=>e.id===t)))).filter(Boolean),...l]}(o,t,n)}),s(e.options,"debugTable"))}},O={getInitialState:e=>({columnPinning:{left:[],right:[]},...e}),getDefaultOptions:e=>({onColumnPinningChange:o("columnPinning",e)}),createColumn:(e,t)=>{e.pin=n=>{const l=e.getLeafColumns().map((e=>e.id)).filter(Boolean);t.setColumnPinning((e=>{var t,o,r,i,a,s;return"right"===n?{left:(null!=(r=null==e?void 0:e.left)?r:[]).filter((e=>!(null!=l&&l.includes(e)))),right:[...(null!=(i=null==e?void 0:e.right)?i:[]).filter((e=>!(null!=l&&l.includes(e)))),...l]}:"left"===n?{left:[...(null!=(a=null==e?void 0:e.left)?a:[]).filter((e=>!(null!=l&&l.includes(e)))),...l],right:(null!=(s=null==e?void 0:e.right)?s:[]).filter((e=>!(null!=l&&l.includes(e))))}:{left:(null!=(t=null==e?void 0:e.left)?t:[]).filter((e=>!(null!=l&&l.includes(e)))),right:(null!=(o=null==e?void 0:e.right)?o:[]).filter((e=>!(null!=l&&l.includes(e))))}}))},e.getCanPin=()=>e.getLeafColumns().some((e=>{var n,l,o;return(null==(n=e.columnDef.enablePinning)||n)&&(null==(l=null!=(o=t.options.enableColumnPinning)?o:t.options.enablePinning)||l)})),e.getIsPinned=()=>{const n=e.getLeafColumns().map((e=>e.id)),{left:l,right:o}=t.getState().columnPinning,r=n.some((e=>null==l?void 0:l.includes(e))),i=n.some((e=>null==o?void 0:o.includes(e)));return r?"left":!!i&&"right"},e.getPinnedIndex=()=>{var n,l;const o=e.getIsPinned();return o?null!=(n=null==(l=t.getState().columnPinning)||null==(l=l[o])?void 0:l.indexOf(e.id))?n:-1:0}},createRow:(e,t)=>{e.getCenterVisibleCells=a((()=>[e._getAllVisibleCells(),t.getState().columnPinning.left,t.getState().columnPinning.right]),((e,t,n)=>{const l=[...null!=t?t:[],...null!=n?n:[]];return e.filter((e=>!l.includes(e.column.id)))}),s(t.options,"debugRows")),e.getLeftVisibleCells=a((()=>[e._getAllVisibleCells(),t.getState().columnPinning.left]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.column.id===t)))).filter(Boolean).map((e=>({...e,position:"left"})))),s(t.options,"debugRows")),e.getRightVisibleCells=a((()=>[e._getAllVisibleCells(),t.getState().columnPinning.right]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.column.id===t)))).filter(Boolean).map((e=>({...e,position:"right"})))),s(t.options,"debugRows"))},createTable:e=>{e.setColumnPinning=t=>null==e.options.onColumnPinningChange?void 0:e.options.onColumnPinningChange(t),e.resetColumnPinning=t=>{var n,l;return e.setColumnPinning(t?{left:[],right:[]}:null!=(n=null==(l=e.initialState)?void 0:l.columnPinning)?n:{left:[],right:[]})},e.getIsSomeColumnsPinned=t=>{var n;const l=e.getState().columnPinning;var o,r;return t?Boolean(null==(n=l[t])?void 0:n.length):Boolean((null==(o=l.left)?void 0:o.length)||(null==(r=l.right)?void 0:r.length))},e.getLeftLeafColumns=a((()=>[e.getAllLeafColumns(),e.getState().columnPinning.left]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.id===t)))).filter(Boolean)),s(e.options,"debugColumns")),e.getRightLeafColumns=a((()=>[e.getAllLeafColumns(),e.getState().columnPinning.right]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.id===t)))).filter(Boolean)),s(e.options,"debugColumns")),e.getCenterLeafColumns=a((()=>[e.getAllLeafColumns(),e.getState().columnPinning.left,e.getState().columnPinning.right]),((e,t,n)=>{const l=[...null!=t?t:[],...null!=n?n:[]];return e.filter((e=>!l.includes(e.id)))}),s(e.options,"debugColumns"))}},_={size:150,minSize:20,maxSize:Number.MAX_SAFE_INTEGER},z={getDefaultColumnDef:()=>_,getInitialState:e=>({columnSizing:{},columnSizingInfo:{startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,isResizingColumn:!1,columnSizingStart:[]},...e}),getDefaultOptions:e=>({columnResizeMode:"onEnd",columnResizeDirection:"ltr",onColumnSizingChange:o("columnSizing",e),onColumnSizingInfoChange:o("columnSizingInfo",e)}),createColumn:(e,t)=>{e.getSize=()=>{var n,l,o;const r=t.getState().columnSizing[e.id];return Math.min(Math.max(null!=(n=e.columnDef.minSize)?n:_.minSize,null!=(l=null!=r?r:e.columnDef.size)?l:_.size),null!=(o=e.columnDef.maxSize)?o:_.maxSize)},e.getStart=a((e=>[e,H(t,e),t.getState().columnSizing]),((t,n)=>n.slice(0,e.getIndex(t)).reduce(((e,t)=>e+t.getSize()),0)),s(t.options,"debugColumns")),e.getAfter=a((e=>[e,H(t,e),t.getState().columnSizing]),((t,n)=>n.slice(e.getIndex(t)+1).reduce(((e,t)=>e+t.getSize()),0)),s(t.options,"debugColumns")),e.resetSize=()=>{t.setColumnSizing((t=>{let{[e.id]:n,...l}=t;return l}))},e.getCanResize=()=>{var n,l;return(null==(n=e.columnDef.enableResizing)||n)&&(null==(l=t.options.enableColumnResizing)||l)},e.getIsResizing=()=>t.getState().columnSizingInfo.isResizingColumn===e.id},createHeader:(e,t)=>{e.getSize=()=>{let t=0;const n=e=>{var l;e.subHeaders.length?e.subHeaders.forEach(n):t+=null!=(l=e.column.getSize())?l:0};return n(e),t},e.getStart=()=>{if(e.index>0){const t=e.headerGroup.headers[e.index-1];return t.getStart()+t.getSize()}return 0},e.getResizeHandler=n=>{const l=t.getColumn(e.column.id),o=null==l?void 0:l.getCanResize();return r=>{if(!l||!o)return;if(null==r.persist||r.persist(),N(r)&&r.touches&&r.touches.length>1)return;const i=e.getSize(),a=e?e.getLeafHeaders().map((e=>[e.column.id,e.column.getSize()])):[[l.id,l.getSize()]],s=N(r)?Math.round(r.touches[0].clientX):r.clientX,u={},d=(e,n)=>{"number"===typeof n&&(t.setColumnSizingInfo((e=>{var l,o;const r="rtl"===t.options.columnResizeDirection?-1:1,i=(n-(null!=(l=null==e?void 0:e.startOffset)?l:0))*r,a=Math.max(i/(null!=(o=null==e?void 0:e.startSize)?o:0),-.999999);return e.columnSizingStart.forEach((e=>{let[t,n]=e;u[t]=Math.round(100*Math.max(n+n*a,0))/100})),{...e,deltaOffset:i,deltaPercentage:a}})),"onChange"!==t.options.columnResizeMode&&"end"!==e||t.setColumnSizing((e=>({...e,...u}))))},g=e=>d("move",e),c=e=>{d("end",e),t.setColumnSizingInfo((e=>({...e,isResizingColumn:!1,startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,columnSizingStart:[]})))},p=n||"undefined"!==typeof document?document:null,m={moveHandler:e=>g(e.clientX),upHandler:e=>{null==p||p.removeEventListener("mousemove",m.moveHandler),null==p||p.removeEventListener("mouseup",m.upHandler),c(e.clientX)}},f={moveHandler:e=>(e.cancelable&&(e.preventDefault(),e.stopPropagation()),g(e.touches[0].clientX),!1),upHandler:e=>{var t;null==p||p.removeEventListener("touchmove",f.moveHandler),null==p||p.removeEventListener("touchend",f.upHandler),e.cancelable&&(e.preventDefault(),e.stopPropagation()),c(null==(t=e.touches[0])?void 0:t.clientX)}},v=!!function(){if("boolean"===typeof G)return G;let e=!1;try{const t={get passive(){return e=!0,!1}},n=()=>{};window.addEventListener("test",n,t),window.removeEventListener("test",n)}catch(t){e=!1}return G=e,G}()&&{passive:!1};N(r)?(null==p||p.addEventListener("touchmove",f.moveHandler,v),null==p||p.addEventListener("touchend",f.upHandler,v)):(null==p||p.addEventListener("mousemove",m.moveHandler,v),null==p||p.addEventListener("mouseup",m.upHandler,v)),t.setColumnSizingInfo((e=>({...e,startOffset:s,startSize:i,deltaOffset:0,deltaPercentage:0,columnSizingStart:a,isResizingColumn:l.id})))}}},createTable:e=>{e.setColumnSizing=t=>null==e.options.onColumnSizingChange?void 0:e.options.onColumnSizingChange(t),e.setColumnSizingInfo=t=>null==e.options.onColumnSizingInfoChange?void 0:e.options.onColumnSizingInfoChange(t),e.resetColumnSizing=t=>{var n;e.setColumnSizing(t?{}:null!=(n=e.initialState.columnSizing)?n:{})},e.resetHeaderSizeInfo=t=>{var n;e.setColumnSizingInfo(t?{startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,isResizingColumn:!1,columnSizingStart:[]}:null!=(n=e.initialState.columnSizingInfo)?n:{startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,isResizingColumn:!1,columnSizingStart:[]})},e.getTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0},e.getLeftTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getLeftHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0},e.getCenterTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getCenterHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0},e.getRightTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getRightHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0}}};let G=null;function N(e){return"touchstart"===e.type}function H(e,t){return t?"center"===t?e.getCenterVisibleLeafColumns():"left"===t?e.getLeftVisibleLeafColumns():e.getRightVisibleLeafColumns():e.getVisibleLeafColumns()}const A={getInitialState:e=>({rowSelection:{},...e}),getDefaultOptions:e=>({onRowSelectionChange:o("rowSelection",e),enableRowSelection:!0,enableMultiRowSelection:!0,enableSubRowSelection:!0}),createTable:e=>{e.setRowSelection=t=>null==e.options.onRowSelectionChange?void 0:e.options.onRowSelectionChange(t),e.resetRowSelection=t=>{var n;return e.setRowSelection(t?{}:null!=(n=e.initialState.rowSelection)?n:{})},e.toggleAllRowsSelected=t=>{e.setRowSelection((n=>{t="undefined"!==typeof t?t:!e.getIsAllRowsSelected();const l={...n},o=e.getPreGroupedRowModel().flatRows;return t?o.forEach((e=>{e.getCanSelect()&&(l[e.id]=!0)})):o.forEach((e=>{delete l[e.id]})),l}))},e.toggleAllPageRowsSelected=t=>e.setRowSelection((n=>{const l="undefined"!==typeof t?t:!e.getIsAllPageRowsSelected(),o={...n};return e.getRowModel().rows.forEach((t=>{D(o,t.id,l,!0,e)})),o})),e.getPreSelectedRowModel=()=>e.getCoreRowModel(),e.getSelectedRowModel=a((()=>[e.getState().rowSelection,e.getCoreRowModel()]),((t,n)=>Object.keys(t).length?L(e,n):{rows:[],flatRows:[],rowsById:{}}),s(e.options,"debugTable")),e.getFilteredSelectedRowModel=a((()=>[e.getState().rowSelection,e.getFilteredRowModel()]),((t,n)=>Object.keys(t).length?L(e,n):{rows:[],flatRows:[],rowsById:{}}),s(e.options,"debugTable")),e.getGroupedSelectedRowModel=a((()=>[e.getState().rowSelection,e.getSortedRowModel()]),((t,n)=>Object.keys(t).length?L(e,n):{rows:[],flatRows:[],rowsById:{}}),s(e.options,"debugTable")),e.getIsAllRowsSelected=()=>{const t=e.getFilteredRowModel().flatRows,{rowSelection:n}=e.getState();let l=Boolean(t.length&&Object.keys(n).length);return l&&t.some((e=>e.getCanSelect()&&!n[e.id]))&&(l=!1),l},e.getIsAllPageRowsSelected=()=>{const t=e.getPaginationRowModel().flatRows.filter((e=>e.getCanSelect())),{rowSelection:n}=e.getState();let l=!!t.length;return l&&t.some((e=>!n[e.id]))&&(l=!1),l},e.getIsSomeRowsSelected=()=>{var t;const n=Object.keys(null!=(t=e.getState().rowSelection)?t:{}).length;return n>0&&n{const t=e.getPaginationRowModel().flatRows;return!e.getIsAllPageRowsSelected()&&t.filter((e=>e.getCanSelect())).some((e=>e.getIsSelected()||e.getIsSomeSelected()))},e.getToggleAllRowsSelectedHandler=()=>t=>{e.toggleAllRowsSelected(t.target.checked)},e.getToggleAllPageRowsSelectedHandler=()=>t=>{e.toggleAllPageRowsSelected(t.target.checked)}},createRow:(e,t)=>{e.toggleSelected=(n,l)=>{const o=e.getIsSelected();t.setRowSelection((r=>{var i;if(n="undefined"!==typeof n?n:!o,e.getCanSelect()&&o===n)return r;const a={...r};return D(a,e.id,n,null==(i=null==l?void 0:l.selectChildren)||i,t),a}))},e.getIsSelected=()=>{const{rowSelection:n}=t.getState();return j(e,n)},e.getIsSomeSelected=()=>{const{rowSelection:n}=t.getState();return"some"===T(e,n)},e.getIsAllSubRowsSelected=()=>{const{rowSelection:n}=t.getState();return"all"===T(e,n)},e.getCanSelect=()=>{var n;return"function"===typeof t.options.enableRowSelection?t.options.enableRowSelection(e):null==(n=t.options.enableRowSelection)||n},e.getCanSelectSubRows=()=>{var n;return"function"===typeof t.options.enableSubRowSelection?t.options.enableSubRowSelection(e):null==(n=t.options.enableSubRowSelection)||n},e.getCanMultiSelect=()=>{var n;return"function"===typeof t.options.enableMultiRowSelection?t.options.enableMultiRowSelection(e):null==(n=t.options.enableMultiRowSelection)||n},e.getToggleSelectedHandler=()=>{const t=e.getCanSelect();return n=>{var l;t&&e.toggleSelected(null==(l=n.target)?void 0:l.checked)}}}},D=(e,t,n,l,o)=>{var r;const i=o.getRow(t,!0);n?(i.getCanMultiSelect()||Object.keys(e).forEach((t=>delete e[t])),i.getCanSelect()&&(e[t]=!0)):delete e[t],l&&null!=(r=i.subRows)&&r.length&&i.getCanSelectSubRows()&&i.subRows.forEach((t=>D(e,t.id,n,l,o)))};function L(e,t){const n=e.getState().rowSelection,l=[],o={},r=function(e,t){return e.map((e=>{var t;const i=j(e,n);if(i&&(l.push(e),o[e.id]=e),null!=(t=e.subRows)&&t.length&&(e={...e,subRows:r(e.subRows)}),i)return e})).filter(Boolean)};return{rows:r(t.rows),flatRows:l,rowsById:o}}function j(e,t){var n;return null!=(n=t[e.id])&&n}function T(e,t,n){var l;if(null==(l=e.subRows)||!l.length)return!1;let o=!0,r=!1;return e.subRows.forEach((e=>{if((!r||o)&&(e.getCanSelect()&&(j(e,t)?r=!0:o=!1),e.subRows&&e.subRows.length)){const n=T(e,t);"all"===n?r=!0:"some"===n?(r=!0,o=!1):o=!1}})),o?"all":!!r&&"some"}const k=/([0-9]+)/gm;function B(e,t){return e===t?0:e>t?1:-1}function q(e){return"number"===typeof e?isNaN(e)||e===1/0||e===-1/0?"":String(e):"string"===typeof e?e:""}function $(e,t){const n=e.split(k).filter(Boolean),l=t.split(k).filter(Boolean);for(;n.length&&l.length;){const e=n.shift(),t=l.shift(),o=parseInt(e,10),r=parseInt(t,10),i=[o,r].sort();if(isNaN(i[0])){if(e>t)return 1;if(t>e)return-1}else{if(isNaN(i[1]))return isNaN(o)?-1:1;if(o>r)return 1;if(r>o)return-1}}return n.length-l.length}const U={alphanumeric:(e,t,n)=>$(q(e.getValue(n)).toLowerCase(),q(t.getValue(n)).toLowerCase()),alphanumericCaseSensitive:(e,t,n)=>$(q(e.getValue(n)),q(t.getValue(n))),text:(e,t,n)=>B(q(e.getValue(n)).toLowerCase(),q(t.getValue(n)).toLowerCase()),textCaseSensitive:(e,t,n)=>B(q(e.getValue(n)),q(t.getValue(n))),datetime:(e,t,n)=>{const l=e.getValue(n),o=t.getValue(n);return l>o?1:lB(e.getValue(n),t.getValue(n))},K=[g,{getInitialState:e=>({columnVisibility:{},...e}),getDefaultOptions:e=>({onColumnVisibilityChange:o("columnVisibility",e)}),createColumn:(e,t)=>{e.toggleVisibility=n=>{e.getCanHide()&&t.setColumnVisibility((t=>({...t,[e.id]:null!=n?n:!e.getIsVisible()})))},e.getIsVisible=()=>{var n,l;const o=e.columns;return null==(n=o.length?o.some((e=>e.getIsVisible())):null==(l=t.getState().columnVisibility)?void 0:l[e.id])||n},e.getCanHide=()=>{var n,l;return(null==(n=e.columnDef.enableHiding)||n)&&(null==(l=t.options.enableHiding)||l)},e.getToggleVisibilityHandler=()=>t=>{null==e.toggleVisibility||e.toggleVisibility(t.target.checked)}},createRow:(e,t)=>{e._getAllVisibleCells=a((()=>[e.getAllCells(),t.getState().columnVisibility]),(e=>e.filter((e=>e.column.getIsVisible()))),s(t.options,"debugRows")),e.getVisibleCells=a((()=>[e.getLeftVisibleCells(),e.getCenterVisibleCells(),e.getRightVisibleCells()]),((e,t,n)=>[...e,...t,...n]),s(t.options,"debugRows"))},createTable:e=>{const t=(t,n)=>a((()=>[n(),n().filter((e=>e.getIsVisible())).map((e=>e.id)).join("_")]),(e=>e.filter((e=>null==e.getIsVisible?void 0:e.getIsVisible()))),s(e.options,"debugColumns"));e.getVisibleFlatColumns=t(0,(()=>e.getAllFlatColumns())),e.getVisibleLeafColumns=t(0,(()=>e.getAllLeafColumns())),e.getLeftVisibleLeafColumns=t(0,(()=>e.getLeftLeafColumns())),e.getRightVisibleLeafColumns=t(0,(()=>e.getRightLeafColumns())),e.getCenterVisibleLeafColumns=t(0,(()=>e.getCenterLeafColumns())),e.setColumnVisibility=t=>null==e.options.onColumnVisibilityChange?void 0:e.options.onColumnVisibilityChange(t),e.resetColumnVisibility=t=>{var n;e.setColumnVisibility(t?{}:null!=(n=e.initialState.columnVisibility)?n:{})},e.toggleAllColumnsVisible=t=>{var n;t=null!=(n=t)?n:!e.getIsAllColumnsVisible(),e.setColumnVisibility(e.getAllLeafColumns().reduce(((e,n)=>({...e,[n.id]:t||!(null!=n.getCanHide&&n.getCanHide())})),{}))},e.getIsAllColumnsVisible=()=>!e.getAllLeafColumns().some((e=>!(null!=e.getIsVisible&&e.getIsVisible()))),e.getIsSomeColumnsVisible=()=>e.getAllLeafColumns().some((e=>null==e.getIsVisible?void 0:e.getIsVisible())),e.getToggleAllColumnsVisibilityHandler=()=>t=>{var n;e.toggleAllColumnsVisible(null==(n=t.target)?void 0:n.checked)}}},V,O,m,M,{createTable:e=>{e._getGlobalFacetedRowModel=e.options.getFacetedRowModel&&e.options.getFacetedRowModel(e,"__global__"),e.getGlobalFacetedRowModel=()=>e.options.manualFiltering||!e._getGlobalFacetedRowModel?e.getPreFilteredRowModel():e._getGlobalFacetedRowModel(),e._getGlobalFacetedUniqueValues=e.options.getFacetedUniqueValues&&e.options.getFacetedUniqueValues(e,"__global__"),e.getGlobalFacetedUniqueValues=()=>e._getGlobalFacetedUniqueValues?e._getGlobalFacetedUniqueValues():new Map,e._getGlobalFacetedMinMaxValues=e.options.getFacetedMinMaxValues&&e.options.getFacetedMinMaxValues(e,"__global__"),e.getGlobalFacetedMinMaxValues=()=>{if(e._getGlobalFacetedMinMaxValues)return e._getGlobalFacetedMinMaxValues()}}},{getInitialState:e=>({globalFilter:void 0,...e}),getDefaultOptions:e=>({onGlobalFilterChange:o("globalFilter",e),globalFilterFn:"auto",getColumnCanGlobalFilter:t=>{var n;const l=null==(n=e.getCoreRowModel().flatRows[0])||null==(n=n._getAllCellsByColumnId()[t.id])?void 0:n.getValue();return"string"===typeof l||"number"===typeof l}}),createColumn:(e,t)=>{e.getCanGlobalFilter=()=>{var n,l,o,r;return(null==(n=e.columnDef.enableGlobalFilter)||n)&&(null==(l=t.options.enableGlobalFilter)||l)&&(null==(o=t.options.enableFilters)||o)&&(null==(r=null==t.options.getColumnCanGlobalFilter?void 0:t.options.getColumnCanGlobalFilter(e))||r)&&!!e.accessorFn}},createTable:e=>{e.getGlobalAutoFilterFn=()=>I.includesString,e.getGlobalFilterFn=()=>{var t,n;const{globalFilterFn:l}=e.options;return r(l)?l:"auto"===l?e.getGlobalAutoFilterFn():null!=(t=null==(n=e.options.filterFns)?void 0:n[l])?t:I[l]},e.setGlobalFilter=t=>{null==e.options.onGlobalFilterChange||e.options.onGlobalFilterChange(t)},e.resetGlobalFilter=t=>{e.setGlobalFilter(t?void 0:e.initialState.globalFilter)}}},{getInitialState:e=>({sorting:[],...e}),getDefaultColumnDef:()=>({sortingFn:"auto",sortUndefined:1}),getDefaultOptions:e=>({onSortingChange:o("sorting",e),isMultiSortEvent:e=>e.shiftKey}),createColumn:(e,t)=>{e.getAutoSortingFn=()=>{const n=t.getFilteredRowModel().flatRows.slice(10);let l=!1;for(const t of n){const n=null==t?void 0:t.getValue(e.id);if("[object Date]"===Object.prototype.toString.call(n))return U.datetime;if("string"===typeof n&&(l=!0,n.split(k).length>1))return U.alphanumeric}return l?U.text:U.basic},e.getAutoSortDir=()=>{const n=t.getFilteredRowModel().flatRows[0];return"string"===typeof(null==n?void 0:n.getValue(e.id))?"asc":"desc"},e.getSortingFn=()=>{var n,l;if(!e)throw new Error;return r(e.columnDef.sortingFn)?e.columnDef.sortingFn:"auto"===e.columnDef.sortingFn?e.getAutoSortingFn():null!=(n=null==(l=t.options.sortingFns)?void 0:l[e.columnDef.sortingFn])?n:U[e.columnDef.sortingFn]},e.toggleSorting=(n,l)=>{const o=e.getNextSortingOrder(),r="undefined"!==typeof n&&null!==n;t.setSorting((i=>{const a=null==i?void 0:i.find((t=>t.id===e.id)),s=null==i?void 0:i.findIndex((t=>t.id===e.id));let u,d=[],g=r?n:"desc"===o;var c;(u=null!=i&&i.length&&e.getCanMultiSort()&&l?a?"toggle":"add":null!=i&&i.length&&s!==i.length-1?"replace":a?"toggle":"replace","toggle"===u&&(r||o||(u="remove")),"add"===u)?(d=[...i,{id:e.id,desc:g}],d.splice(0,d.length-(null!=(c=t.options.maxMultiSortColCount)?c:Number.MAX_SAFE_INTEGER))):d="toggle"===u?i.map((t=>t.id===e.id?{...t,desc:g}:t)):"remove"===u?i.filter((t=>t.id!==e.id)):[{id:e.id,desc:g}];return d}))},e.getFirstSortDir=()=>{var n,l;return(null!=(n=null!=(l=e.columnDef.sortDescFirst)?l:t.options.sortDescFirst)?n:"desc"===e.getAutoSortDir())?"desc":"asc"},e.getNextSortingOrder=n=>{var l,o;const r=e.getFirstSortDir(),i=e.getIsSorted();return i?!!(i===r||null!=(l=t.options.enableSortingRemoval)&&!l||n&&null!=(o=t.options.enableMultiRemove)&&!o)&&("desc"===i?"asc":"desc"):r},e.getCanSort=()=>{var n,l;return(null==(n=e.columnDef.enableSorting)||n)&&(null==(l=t.options.enableSorting)||l)&&!!e.accessorFn},e.getCanMultiSort=()=>{var n,l;return null!=(n=null!=(l=e.columnDef.enableMultiSort)?l:t.options.enableMultiSort)?n:!!e.accessorFn},e.getIsSorted=()=>{var n;const l=null==(n=t.getState().sorting)?void 0:n.find((t=>t.id===e.id));return!!l&&(l.desc?"desc":"asc")},e.getSortIndex=()=>{var n,l;return null!=(n=null==(l=t.getState().sorting)?void 0:l.findIndex((t=>t.id===e.id)))?n:-1},e.clearSorting=()=>{t.setSorting((t=>null!=t&&t.length?t.filter((t=>t.id!==e.id)):[]))},e.getToggleSortingHandler=()=>{const n=e.getCanSort();return l=>{n&&(null==l.persist||l.persist(),null==e.toggleSorting||e.toggleSorting(void 0,!!e.getCanMultiSort()&&(null==t.options.isMultiSortEvent?void 0:t.options.isMultiSortEvent(l))))}}},createTable:e=>{e.setSorting=t=>null==e.options.onSortingChange?void 0:e.options.onSortingChange(t),e.resetSorting=t=>{var n,l;e.setSorting(t?[]:null!=(n=null==(l=e.initialState)?void 0:l.sorting)?n:[])},e.getPreSortedRowModel=()=>e.getGroupedRowModel(),e.getSortedRowModel=()=>(!e._getSortedRowModel&&e.options.getSortedRowModel&&(e._getSortedRowModel=e.options.getSortedRowModel(e)),e.options.manualSorting||!e._getSortedRowModel?e.getPreSortedRowModel():e._getSortedRowModel())}},E,{getInitialState:e=>({expanded:{},...e}),getDefaultOptions:e=>({onExpandedChange:o("expanded",e),paginateExpandedRows:!0}),createTable:e=>{let t=!1,n=!1;e._autoResetExpanded=()=>{var l,o;if(t){if(null!=(l=null!=(o=e.options.autoResetAll)?o:e.options.autoResetExpanded)?l:!e.options.manualExpanding){if(n)return;n=!0,e._queue((()=>{e.resetExpanded(),n=!1}))}}else e._queue((()=>{t=!0}))},e.setExpanded=t=>null==e.options.onExpandedChange?void 0:e.options.onExpandedChange(t),e.toggleAllRowsExpanded=t=>{(null!=t?t:!e.getIsAllRowsExpanded())?e.setExpanded(!0):e.setExpanded({})},e.resetExpanded=t=>{var n,l;e.setExpanded(t?{}:null!=(n=null==(l=e.initialState)?void 0:l.expanded)?n:{})},e.getCanSomeRowsExpand=()=>e.getPrePaginationRowModel().flatRows.some((e=>e.getCanExpand())),e.getToggleAllRowsExpandedHandler=()=>t=>{null==t.persist||t.persist(),e.toggleAllRowsExpanded()},e.getIsSomeRowsExpanded=()=>{const t=e.getState().expanded;return!0===t||Object.values(t).some(Boolean)},e.getIsAllRowsExpanded=()=>{const t=e.getState().expanded;return"boolean"===typeof t?!0===t:!!Object.keys(t).length&&!e.getRowModel().flatRows.some((e=>!e.getIsExpanded()))},e.getExpandedDepth=()=>{let t=0;return(!0===e.getState().expanded?Object.keys(e.getRowModel().rowsById):Object.keys(e.getState().expanded)).forEach((e=>{const n=e.split(".");t=Math.max(t,n.length)})),t},e.getPreExpandedRowModel=()=>e.getSortedRowModel(),e.getExpandedRowModel=()=>(!e._getExpandedRowModel&&e.options.getExpandedRowModel&&(e._getExpandedRowModel=e.options.getExpandedRowModel(e)),e.options.manualExpanding||!e._getExpandedRowModel?e.getPreExpandedRowModel():e._getExpandedRowModel())},createRow:(e,t)=>{e.toggleExpanded=n=>{t.setExpanded((l=>{var o;const r=!0===l||!(null==l||!l[e.id]);let i={};if(!0===l?Object.keys(t.getRowModel().rowsById).forEach((e=>{i[e]=!0})):i=l,n=null!=(o=n)?o:!r,!r&&n)return{...i,[e.id]:!0};if(r&&!n){const{[e.id]:t,...n}=i;return n}return l}))},e.getIsExpanded=()=>{var n;const l=t.getState().expanded;return!!(null!=(n=null==t.options.getIsRowExpanded?void 0:t.options.getIsRowExpanded(e))?n:!0===l||(null==l?void 0:l[e.id]))},e.getCanExpand=()=>{var n,l,o;return null!=(n=null==t.options.getRowCanExpand?void 0:t.options.getRowCanExpand(e))?n:(null==(l=t.options.enableExpanding)||l)&&!(null==(o=e.subRows)||!o.length)},e.getIsAllParentsExpanded=()=>{let n=!0,l=e;for(;n&&l.parentId;)l=t.getRow(l.parentId,!0),n=l.getIsExpanded();return n},e.getToggleExpandedHandler=()=>{const t=e.getCanExpand();return()=>{t&&e.toggleExpanded()}}}},{getInitialState:e=>({...e,pagination:{pageIndex:0,pageSize:10,...null==e?void 0:e.pagination}}),getDefaultOptions:e=>({onPaginationChange:o("pagination",e)}),createTable:e=>{let t=!1,n=!1;e._autoResetPageIndex=()=>{var l,o;if(t){if(null!=(l=null!=(o=e.options.autoResetAll)?o:e.options.autoResetPageIndex)?l:!e.options.manualPagination){if(n)return;n=!0,e._queue((()=>{e.resetPageIndex(),n=!1}))}}else e._queue((()=>{t=!0}))},e.setPagination=t=>null==e.options.onPaginationChange?void 0:e.options.onPaginationChange((e=>l(t,e))),e.resetPagination=t=>{var n;e.setPagination(t?{pageIndex:0,pageSize:10}:null!=(n=e.initialState.pagination)?n:{pageIndex:0,pageSize:10})},e.setPageIndex=t=>{e.setPagination((n=>{let o=l(t,n.pageIndex);const r="undefined"===typeof e.options.pageCount||-1===e.options.pageCount?Number.MAX_SAFE_INTEGER:e.options.pageCount-1;return o=Math.max(0,Math.min(o,r)),{...n,pageIndex:o}}))},e.resetPageIndex=t=>{var n,l;e.setPageIndex(t?0:null!=(n=null==(l=e.initialState)||null==(l=l.pagination)?void 0:l.pageIndex)?n:0)},e.resetPageSize=t=>{var n,l;e.setPageSize(t?10:null!=(n=null==(l=e.initialState)||null==(l=l.pagination)?void 0:l.pageSize)?n:10)},e.setPageSize=t=>{e.setPagination((e=>{const n=Math.max(1,l(t,e.pageSize)),o=e.pageSize*e.pageIndex,r=Math.floor(o/n);return{...e,pageIndex:r,pageSize:n}}))},e.setPageCount=t=>e.setPagination((n=>{var o;let r=l(t,null!=(o=e.options.pageCount)?o:-1);return"number"===typeof r&&(r=Math.max(-1,r)),{...n,pageCount:r}})),e.getPageOptions=a((()=>[e.getPageCount()]),(e=>{let t=[];return e&&e>0&&(t=[...new Array(e)].fill(null).map(((e,t)=>t))),t}),s(e.options,"debugTable")),e.getCanPreviousPage=()=>e.getState().pagination.pageIndex>0,e.getCanNextPage=()=>{const{pageIndex:t}=e.getState().pagination,n=e.getPageCount();return-1===n||0!==n&&te.setPageIndex((e=>e-1)),e.nextPage=()=>e.setPageIndex((e=>e+1)),e.firstPage=()=>e.setPageIndex(0),e.lastPage=()=>e.setPageIndex(e.getPageCount()-1),e.getPrePaginationRowModel=()=>e.getExpandedRowModel(),e.getPaginationRowModel=()=>(!e._getPaginationRowModel&&e.options.getPaginationRowModel&&(e._getPaginationRowModel=e.options.getPaginationRowModel(e)),e.options.manualPagination||!e._getPaginationRowModel?e.getPrePaginationRowModel():e._getPaginationRowModel()),e.getPageCount=()=>{var t;return null!=(t=e.options.pageCount)?t:Math.ceil(e.getRowCount()/e.getState().pagination.pageSize)},e.getRowCount=()=>{var t;return null!=(t=e.options.rowCount)?t:e.getPrePaginationRowModel().rows.length}}},{getInitialState:e=>({rowPinning:{top:[],bottom:[]},...e}),getDefaultOptions:e=>({onRowPinningChange:o("rowPinning",e)}),createRow:(e,t)=>{e.pin=(n,l,o)=>{const r=l?e.getLeafRows().map((e=>{let{id:t}=e;return t})):[],i=o?e.getParentRows().map((e=>{let{id:t}=e;return t})):[],a=new Set([...i,e.id,...r]);t.setRowPinning((e=>{var t,l,o,r,i,s;return"bottom"===n?{top:(null!=(o=null==e?void 0:e.top)?o:[]).filter((e=>!(null!=a&&a.has(e)))),bottom:[...(null!=(r=null==e?void 0:e.bottom)?r:[]).filter((e=>!(null!=a&&a.has(e)))),...Array.from(a)]}:"top"===n?{top:[...(null!=(i=null==e?void 0:e.top)?i:[]).filter((e=>!(null!=a&&a.has(e)))),...Array.from(a)],bottom:(null!=(s=null==e?void 0:e.bottom)?s:[]).filter((e=>!(null!=a&&a.has(e))))}:{top:(null!=(t=null==e?void 0:e.top)?t:[]).filter((e=>!(null!=a&&a.has(e)))),bottom:(null!=(l=null==e?void 0:e.bottom)?l:[]).filter((e=>!(null!=a&&a.has(e))))}}))},e.getCanPin=()=>{var n;const{enableRowPinning:l,enablePinning:o}=t.options;return"function"===typeof l?l(e):null==(n=null!=l?l:o)||n},e.getIsPinned=()=>{const n=[e.id],{top:l,bottom:o}=t.getState().rowPinning,r=n.some((e=>null==l?void 0:l.includes(e))),i=n.some((e=>null==o?void 0:o.includes(e)));return r?"top":!!i&&"bottom"},e.getPinnedIndex=()=>{var n,l;const o=e.getIsPinned();if(!o)return-1;const r=null==(n="top"===o?t.getTopRows():t.getBottomRows())?void 0:n.map((e=>{let{id:t}=e;return t}));return null!=(l=null==r?void 0:r.indexOf(e.id))?l:-1}},createTable:e=>{e.setRowPinning=t=>null==e.options.onRowPinningChange?void 0:e.options.onRowPinningChange(t),e.resetRowPinning=t=>{var n,l;return e.setRowPinning(t?{top:[],bottom:[]}:null!=(n=null==(l=e.initialState)?void 0:l.rowPinning)?n:{top:[],bottom:[]})},e.getIsSomeRowsPinned=t=>{var n;const l=e.getState().rowPinning;var o,r;return t?Boolean(null==(n=l[t])?void 0:n.length):Boolean((null==(o=l.top)?void 0:o.length)||(null==(r=l.bottom)?void 0:r.length))},e._getPinnedRows=(t,n,l)=>{var o;return(null==(o=e.options.keepPinnedRows)||o?(null!=n?n:[]).map((t=>{const n=e.getRow(t,!0);return n.getIsAllParentsExpanded()?n:null})):(null!=n?n:[]).map((e=>t.find((t=>t.id===e))))).filter(Boolean).map((e=>({...e,position:l})))},e.getTopRows=a((()=>[e.getRowModel().rows,e.getState().rowPinning.top]),((t,n)=>e._getPinnedRows(t,n,"top")),s(e.options,"debugRows")),e.getBottomRows=a((()=>[e.getRowModel().rows,e.getState().rowPinning.bottom]),((t,n)=>e._getPinnedRows(t,n,"bottom")),s(e.options,"debugRows")),e.getCenterRows=a((()=>[e.getRowModel().rows,e.getState().rowPinning.top,e.getState().rowPinning.bottom]),((e,t,n)=>{const l=new Set([...null!=t?t:[],...null!=n?n:[]]);return e.filter((e=>!l.has(e.id)))}),s(e.options,"debugRows"))}},A,z];function X(e){var t,n;const o=[...K,...null!=(t=e._features)?t:[]];let r={_features:o};const i=r._features.reduce(((e,t)=>Object.assign(e,null==t.getDefaultOptions?void 0:t.getDefaultOptions(r))),{});let u={...null!=(n=e.initialState)?n:{}};r._features.forEach((e=>{var t;u=null!=(t=null==e.getInitialState?void 0:e.getInitialState(u))?t:u}));const d=[];let g=!1;const c={_features:o,options:{...i,...e},initialState:u,_queue:e=>{d.push(e),g||(g=!0,Promise.resolve().then((()=>{for(;d.length;)d.shift()();g=!1})).catch((e=>setTimeout((()=>{throw e})))))},reset:()=>{r.setState(r.initialState)},setOptions:e=>{const t=l(e,r.options);r.options=(e=>r.options.mergeOptions?r.options.mergeOptions(i,e):{...i,...e})(t)},getState:()=>r.options.state,setState:e=>{null==r.options.onStateChange||r.options.onStateChange(e)},_getRowId:(e,t,n)=>{var l;return null!=(l=null==r.options.getRowId?void 0:r.options.getRowId(e,t,n))?l:`${n?[n.id,t].join("."):t}`},getCoreRowModel:()=>(r._getCoreRowModel||(r._getCoreRowModel=r.options.getCoreRowModel(r)),r._getCoreRowModel()),getRowModel:()=>r.getPaginationRowModel(),getRow:(e,t)=>{let n=(t?r.getPrePaginationRowModel():r.getRowModel()).rowsById[e];if(!n&&(n=r.getCoreRowModel().rowsById[e],!n))throw new Error;return n},_getDefaultColumnDef:a((()=>[r.options.defaultColumn]),(e=>{var t;return e=null!=(t=e)?t:{},{header:e=>{const t=e.header.column.columnDef;return t.accessorKey?t.accessorKey:t.accessorFn?t.id:null},cell:e=>{var t,n;return null!=(t=null==(n=e.renderValue())||null==n.toString?void 0:n.toString())?t:null},...r._features.reduce(((e,t)=>Object.assign(e,null==t.getDefaultColumnDef?void 0:t.getDefaultColumnDef())),{}),...e}}),s(e,"debugColumns")),_getColumnDefs:()=>r.options.columns,getAllColumns:a((()=>[r._getColumnDefs()]),(e=>{const t=function(e,n,l){return void 0===l&&(l=0),e.map((e=>{const o=function(e,t,n,l){var o,r;const i={...e._getDefaultColumnDef(),...t},u=i.accessorKey;let d,g=null!=(o=null!=(r=i.id)?r:u?"function"===typeof String.prototype.replaceAll?u.replaceAll(".","_"):u.replace(/\./g,"_"):void 0)?o:"string"===typeof i.header?i.header:void 0;if(i.accessorFn?d=i.accessorFn:u&&(d=u.includes(".")?e=>{let t=e;for(const l of u.split(".")){var n;t=null==(n=t)?void 0:n[l]}return t}:e=>e[i.accessorKey]),!g)throw new Error;let c={id:`${String(g)}`,accessorFn:d,parent:l,depth:n,columnDef:i,columns:[],getFlatColumns:a((()=>[!0]),(()=>{var e;return[c,...null==(e=c.columns)?void 0:e.flatMap((e=>e.getFlatColumns()))]}),s(e.options,"debugColumns")),getLeafColumns:a((()=>[e._getOrderColumnsFn()]),(e=>{var t;if(null!=(t=c.columns)&&t.length){let t=c.columns.flatMap((e=>e.getLeafColumns()));return e(t)}return[c]}),s(e.options,"debugColumns"))};for(const a of e._features)null==a.createColumn||a.createColumn(c,e);return c}(r,e,l,n),i=e;return o.columns=i.columns?t(i.columns,o,l+1):[],o}))};return t(e)}),s(e,"debugColumns")),getAllFlatColumns:a((()=>[r.getAllColumns()]),(e=>e.flatMap((e=>e.getFlatColumns()))),s(e,"debugColumns")),_getAllFlatColumnsById:a((()=>[r.getAllFlatColumns()]),(e=>e.reduce(((e,t)=>(e[t.id]=t,e)),{})),s(e,"debugColumns")),getAllLeafColumns:a((()=>[r.getAllColumns(),r._getOrderColumnsFn()]),((e,t)=>t(e.flatMap((e=>e.getLeafColumns())))),s(e,"debugColumns")),getColumn:e=>r._getAllFlatColumnsById()[e]};Object.assign(r,c);for(let l=0;la((()=>[e.options.data]),(t=>{const n={rows:[],flatRows:[],rowsById:{}},l=function(t,o,r){void 0===o&&(o=0);const i=[];for(let s=0;se._autoResetPageIndex())))}function W(){return e=>a((()=>[e.getState().expanded,e.getPreExpandedRowModel(),e.options.paginateExpandedRows]),((e,t,n)=>!t.rows.length||!0!==e&&!Object.keys(null!=e?e:{}).length?t:n?J(t):t),s(e.options,"debugTable"))}function J(e){const t=[],n=e=>{var l;t.push(e),null!=(l=e.subRows)&&l.length&&e.getIsExpanded()&&e.subRows.forEach(n)};return e.rows.forEach(n),{rows:t,flatRows:e.flatRows,rowsById:e.rowsById}}function Q(){return e=>a((()=>[e.getState().grouping,e.getPreGroupedRowModel()]),((t,n)=>{if(!n.rows.length||!t.length)return n.rows.forEach((e=>{e.depth=0,e.parentId=void 0})),n;const l=t.filter((t=>e.getColumn(t))),o=[],r={},a=function(t,n,s){if(void 0===n&&(n=0),n>=l.length)return t.map((e=>(e.depth=n,o.push(e),r[e.id]=e,e.subRows&&(e.subRows=a(e.subRows,n+1,e.id)),e)));const u=l[n],d=function(e,t){const n=new Map;return e.reduce(((e,n)=>{const l=`${n.getGroupingValue(t)}`,o=e.get(l);return o?o.push(n):e.set(l,[n]),e}),n)}(t,u),g=Array.from(d.entries()).map(((t,d)=>{let[g,c]=t,m=`${u}:${g}`;m=s?`${s}>${m}`:m;const f=a(c,n+1,m);f.forEach((e=>{e.parentId=m}));const v=n?i(c,(e=>e.subRows)):c,w=p(e,m,v[0].original,d,n,void 0,s);return Object.assign(w,{groupingColumnId:u,groupingValue:g,subRows:f,leafRows:v,getValue:t=>{if(l.includes(t)){if(w._valuesCache.hasOwnProperty(t))return w._valuesCache[t];var n;if(c[0])w._valuesCache[t]=null!=(n=c[0].getValue(t))?n:void 0;return w._valuesCache[t]}if(w._groupingValuesCache.hasOwnProperty(t))return w._groupingValuesCache[t];const o=e.getColumn(t),r=null==o?void 0:o.getAggregationFn();return r?(w._groupingValuesCache[t]=r(t,v,c),w._groupingValuesCache[t]):void 0}}),f.forEach((e=>{o.push(e),r[e.id]=e})),w}));return g},s=a(n.rows,0);return s.forEach((e=>{o.push(e),r[e.id]=e})),{rows:s,flatRows:o,rowsById:r}}),s(e.options,"debugTable",0,(()=>{e._queue((()=>{e._autoResetExpanded(),e._autoResetPageIndex()}))})))}function Y(){return e=>a((()=>[e.getState().sorting,e.getPreSortedRowModel()]),((t,n)=>{if(!n.rows.length||null==t||!t.length)return n;const l=e.getState().sorting,o=[],r=l.filter((t=>{var n;return null==(n=e.getColumn(t.id))?void 0:n.getCanSort()})),i={};r.forEach((t=>{const n=e.getColumn(t.id);n&&(i[t.id]={sortUndefined:n.columnDef.sortUndefined,invertSorting:n.columnDef.invertSorting,sortingFn:n.getSortingFn()})}));const a=e=>{const t=e.map((e=>({...e})));return t.sort(((e,t)=>{for(let l=0;l{var t;o.push(e),null!=(t=e.subRows)&&t.length&&(e.subRows=a(e.subRows))})),t};return{rows:a(n.rows),flatRows:o,rowsById:n.rowsById}}),s(e.options,"debugTable",0,(()=>e._autoResetPageIndex())))}},36590:(e,t,n)=>{n.d(t,{K:()=>r});var l=n(24953),o=n(85720);const r=e=>{var t,n,r,i,a,s,u,d,g,c,p,m,f;const v=Object.assign(Object.assign({},e),{enableColumnPinning:null!==(t=e.enableColumnPinning)&&void 0!==t&&t,enableColumnResizing:null!==(n=e.enableColumnResizing)&&void 0!==n&&n,enableExpanding:null!==(r=e.enableExpanding)&&void 0!==r&&r,enableGrouping:null!==(i=e.enableGrouping)&&void 0!==i&&i,enableMultiRowSelection:null!==(a=e.enableMultiRowSelection)&&void 0!==a&&a,enableRowSelection:null!==(s=e.enableRowSelection)&&void 0!==s&&s,enableSorting:null!==(u=e.enableSorting)&&void 0!==u&&u,getCoreRowModel:null!==(d=e.getCoreRowModel)&&void 0!==d?d:(0,l.HT)(),getExpandedRowModel:e.enableExpanding?null!==(g=e.getExpandedRowModel)&&void 0!==g?g:(0,l.D0)():void 0,getGroupedRowModel:e.enableGrouping?null!==(c=e.getGroupedRowModel)&&void 0!==c?c:(0,l.cU)():void 0,getSortedRowModel:e.enableSorting?null!==(p=e.getSortedRowModel)&&void 0!==p?p:(0,l.h5)():void 0,manualGrouping:null!==(m=e.manualGrouping)&&void 0!==m&&m,manualSorting:null!==(f=e.manualSorting)&&void 0!==f&&f});return(0,o.N4)(v)}},74321:(e,t,n)=>{n.d(t,{S:()=>u});var l=n(59284),o=n(64222),r=n(46898);function i(e){return l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),l.createElement("path",{d:"M4 7h9v3H4z"}))}function a(e){return l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),l.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const s=(0,n(69220).om)("checkbox"),u=l.forwardRef((function(e,t){const{size:n="m",indeterminate:u,disabled:d=!1,content:g,children:c,title:p,style:m,className:f,qa:v}=e,{checked:w,inputProps:h}=(0,o.v)(e),b=g||c,C=l.createElement("span",{className:s("indicator")},l.createElement("span",{className:s("icon"),"aria-hidden":!0},u?l.createElement(i,{className:s("icon-svg",{type:"dash"})}):l.createElement(a,{className:s("icon-svg",{type:"tick"})})),l.createElement("input",Object.assign({},h,{className:s("control")})),l.createElement("span",{className:s("outline")}));return l.createElement(r.m,{ref:t,title:p,style:m,size:n,disabled:d,className:s({size:n,disabled:d,indeterminate:u,checked:w},f),qa:v,control:C},b)}))},76938:(e,t,n)=>{n.d(t,{A:()=>o});var l=n(59284);const o=e=>l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),l.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 1 1-6.445 7.348.75.75 0 1 1 1.487-.194A5.001 5.001 0 1 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 0 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5",clipRule:"evenodd"}))},85720:(e,t,n)=>{n.d(t,{Kv:()=>r,N4:()=>i});var l=n(59284),o=n(24953);function r(e,t){return e?function(e){return"function"===typeof e&&(()=>{const t=Object.getPrototypeOf(e);return t.prototype&&t.prototype.isReactComponent})()}(n=e)||"function"===typeof n||function(e){return"object"===typeof e&&"symbol"===typeof e.$$typeof&&["react.memo","react.forward_ref"].includes(e.$$typeof.description)}(n)?l.createElement(e,t):e:null;var n}function i(e){const t={state:{},onStateChange:()=>{},renderFallbackValue:null,...e},[n]=l.useState((()=>({current:(0,o.ZR)(t)}))),[r,i]=l.useState((()=>n.current.initialState));return n.current.setOptions((t=>({...t,...e,state:{...r,...e.state},onStateChange:t=>{i(t),null==e.onStateChange||e.onStateChange(t)}}))),n.current}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7341.6e678529.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/59172.d3dd36c7.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/7341.6e678529.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/59172.d3dd36c7.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/5924.53ba4f49.chunk.js b/ydb/core/viewer/monitoring/static/js/5924.53ba4f49.chunk.js deleted file mode 100644 index c2065896ad98..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5924.53ba4f49.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5924],{95924:function(e,n,i){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var i=n(e),_={name:"fy",weekdays:"snein_moandei_tiisdei_woansdei_tongersdei_freed_sneon".split("_"),months:"jannewaris_febrewaris_maart_april_maaie_juny_july_augustus_septimber_oktober_novimber_desimber".split("_"),monthsShort:"jan._feb._mrt._apr._mai_jun._jul._aug._sep._okt._nov._des.".split("_"),weekStart:1,weekdaysShort:"si._mo._ti._wo._to._fr._so.".split("_"),weekdaysMin:"Si_Mo_Ti_Wo_To_Fr_So".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD-MM-YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"oer %s",past:"%s lyn",s:"in pear sekonden",m:"ien min\xfat",mm:"%d minuten",h:"ien oere",hh:"%d oeren",d:"ien dei",dd:"%d dagen",M:"ien moanne",MM:"%d moannen",y:"ien jier",yy:"%d jierren"}};return i.default.locale(_,null,!0),_}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/59243.5de594f4.chunk.js b/ydb/core/viewer/monitoring/static/js/59243.5de594f4.chunk.js new file mode 100644 index 000000000000..46428b8dc3fb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/59243.5de594f4.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[59243],{59243:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"am",weekdays:"\u12a5\u1211\u12f5_\u1230\u129e_\u121b\u12ad\u1230\u129e_\u1228\u1261\u12d5_\u1210\u1219\u1235_\u12a0\u122d\u1265_\u1245\u12f3\u121c".split("_"),weekdaysShort:"\u12a5\u1211\u12f5_\u1230\u129e_\u121b\u12ad\u1230_\u1228\u1261\u12d5_\u1210\u1219\u1235_\u12a0\u122d\u1265_\u1245\u12f3\u121c".split("_"),weekdaysMin:"\u12a5\u1211_\u1230\u129e_\u121b\u12ad_\u1228\u1261_\u1210\u1219_\u12a0\u122d_\u1245\u12f3".split("_"),months:"\u1303\u1295\u12cb\u122a_\u134c\u1265\u122f\u122a_\u121b\u122d\u127d_\u12a4\u1355\u122a\u120d_\u121c\u12ed_\u1301\u1295_\u1301\u120b\u12ed_\u12a6\u1308\u1235\u1275_\u1234\u1355\u1274\u121d\u1260\u122d_\u12a6\u12ad\u1276\u1260\u122d_\u1296\u126c\u121d\u1260\u122d_\u12f2\u1234\u121d\u1260\u122d".split("_"),monthsShort:"\u1303\u1295\u12cb_\u134c\u1265\u122f_\u121b\u122d\u127d_\u12a4\u1355\u122a_\u121c\u12ed_\u1301\u1295_\u1301\u120b\u12ed_\u12a6\u1308\u1235_\u1234\u1355\u1274_\u12a6\u12ad\u1276_\u1296\u126c\u121d_\u12f2\u1234\u121d".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"\u1260%s",past:"%s \u1260\u134a\u1275",s:"\u1325\u1242\u1275 \u1230\u12a8\u1295\u12f6\u127d",m:"\u12a0\u1295\u12f5 \u12f0\u1242\u1243",mm:"%d \u12f0\u1242\u1243\u12ce\u127d",h:"\u12a0\u1295\u12f5 \u1230\u12d3\u1275",hh:"%d \u1230\u12d3\u1273\u1275",d:"\u12a0\u1295\u12f5 \u1240\u1295",dd:"%d \u1240\u1293\u1275",M:"\u12a0\u1295\u12f5 \u12c8\u122d",MM:"%d \u12c8\u122b\u1275",y:"\u12a0\u1295\u12f5 \u12d3\u1218\u1275",yy:"%d \u12d3\u1218\u1273\u1275"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"MMMM D \u1363 YYYY",LLL:"MMMM D \u1363 YYYY HH:mm",LLLL:"dddd \u1363 MMMM D \u1363 YYYY HH:mm"},ordinal:function(_){return _+"\u129b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5950.28656717.chunk.js b/ydb/core/viewer/monitoring/static/js/5950.28656717.chunk.js deleted file mode 100644 index 63dfa98c49eb..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5950.28656717.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5950],{85950:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"bg",weekdays:"\u043d\u0435\u0434\u0435\u043b\u044f_\u043f\u043e\u043d\u0435\u0434\u0435\u043b\u043d\u0438\u043a_\u0432\u0442\u043e\u0440\u043d\u0438\u043a_\u0441\u0440\u044f\u0434\u0430_\u0447\u0435\u0442\u0432\u044a\u0440\u0442\u044a\u043a_\u043f\u0435\u0442\u044a\u043a_\u0441\u044a\u0431\u043e\u0442\u0430".split("_"),weekdaysShort:"\u043d\u0435\u0434_\u043f\u043e\u043d_\u0432\u0442\u043e_\u0441\u0440\u044f_\u0447\u0435\u0442_\u043f\u0435\u0442_\u0441\u044a\u0431".split("_"),weekdaysMin:"\u043d\u0434_\u043f\u043d_\u0432\u0442_\u0441\u0440_\u0447\u0442_\u043f\u0442_\u0441\u0431".split("_"),months:"\u044f\u043d\u0443\u0430\u0440\u0438_\u0444\u0435\u0432\u0440\u0443\u0430\u0440\u0438_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0438\u043b_\u043c\u0430\u0439_\u044e\u043d\u0438_\u044e\u043b\u0438_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043f\u0442\u0435\u043c\u0432\u0440\u0438_\u043e\u043a\u0442\u043e\u043c\u0432\u0440\u0438_\u043d\u043e\u0435\u043c\u0432\u0440\u0438_\u0434\u0435\u043a\u0435\u043c\u0432\u0440\u0438".split("_"),monthsShort:"\u044f\u043d\u0440_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0439_\u044e\u043d\u0438_\u044e\u043b\u0438_\u0430\u0432\u0433_\u0441\u0435\u043f_\u043e\u043a\u0442_\u043d\u043e\u0435_\u0434\u0435\u043a".split("_"),weekStart:1,ordinal:function(_){var e=_%100;if(e>10&&e<20)return _+"-\u0442\u0438";var t=_%10;return 1===t?_+"-\u0432\u0438":2===t?_+"-\u0440\u0438":7===t||8===t?_+"-\u043c\u0438":_+"-\u0442\u0438"},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"D.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY H:mm",LLLL:"dddd, D MMMM YYYY H:mm"},relativeTime:{future:"\u0441\u043b\u0435\u0434 %s",past:"\u043f\u0440\u0435\u0434\u0438 %s",s:"\u043d\u044f\u043a\u043e\u043b\u043a\u043e \u0441\u0435\u043a\u0443\u043d\u0434\u0438",m:"\u043c\u0438\u043d\u0443\u0442\u0430",mm:"%d \u043c\u0438\u043d\u0443\u0442\u0438",h:"\u0447\u0430\u0441",hh:"%d \u0447\u0430\u0441\u0430",d:"\u0434\u0435\u043d",dd:"%d \u0434\u0435\u043d\u0430",M:"\u043c\u0435\u0441\u0435\u0446",MM:"%d \u043c\u0435\u0441\u0435\u0446\u0430",y:"\u0433\u043e\u0434\u0438\u043d\u0430",yy:"%d \u0433\u043e\u0434\u0438\u043d\u0438"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5953.cb95c45e.chunk.js b/ydb/core/viewer/monitoring/static/js/5953.cb95c45e.chunk.js deleted file mode 100644 index 5bb76bce7193..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5953.cb95c45e.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5953],{85953:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"th",weekdays:"\u0e2d\u0e32\u0e17\u0e34\u0e15\u0e22\u0e4c_\u0e08\u0e31\u0e19\u0e17\u0e23\u0e4c_\u0e2d\u0e31\u0e07\u0e04\u0e32\u0e23_\u0e1e\u0e38\u0e18_\u0e1e\u0e24\u0e2b\u0e31\u0e2a\u0e1a\u0e14\u0e35_\u0e28\u0e38\u0e01\u0e23\u0e4c_\u0e40\u0e2a\u0e32\u0e23\u0e4c".split("_"),weekdaysShort:"\u0e2d\u0e32\u0e17\u0e34\u0e15\u0e22\u0e4c_\u0e08\u0e31\u0e19\u0e17\u0e23\u0e4c_\u0e2d\u0e31\u0e07\u0e04\u0e32\u0e23_\u0e1e\u0e38\u0e18_\u0e1e\u0e24\u0e2b\u0e31\u0e2a_\u0e28\u0e38\u0e01\u0e23\u0e4c_\u0e40\u0e2a\u0e32\u0e23\u0e4c".split("_"),weekdaysMin:"\u0e2d\u0e32._\u0e08._\u0e2d._\u0e1e._\u0e1e\u0e24._\u0e28._\u0e2a.".split("_"),months:"\u0e21\u0e01\u0e23\u0e32\u0e04\u0e21_\u0e01\u0e38\u0e21\u0e20\u0e32\u0e1e\u0e31\u0e19\u0e18\u0e4c_\u0e21\u0e35\u0e19\u0e32\u0e04\u0e21_\u0e40\u0e21\u0e29\u0e32\u0e22\u0e19_\u0e1e\u0e24\u0e29\u0e20\u0e32\u0e04\u0e21_\u0e21\u0e34\u0e16\u0e38\u0e19\u0e32\u0e22\u0e19_\u0e01\u0e23\u0e01\u0e0e\u0e32\u0e04\u0e21_\u0e2a\u0e34\u0e07\u0e2b\u0e32\u0e04\u0e21_\u0e01\u0e31\u0e19\u0e22\u0e32\u0e22\u0e19_\u0e15\u0e38\u0e25\u0e32\u0e04\u0e21_\u0e1e\u0e24\u0e28\u0e08\u0e34\u0e01\u0e32\u0e22\u0e19_\u0e18\u0e31\u0e19\u0e27\u0e32\u0e04\u0e21".split("_"),monthsShort:"\u0e21.\u0e04._\u0e01.\u0e1e._\u0e21\u0e35.\u0e04._\u0e40\u0e21.\u0e22._\u0e1e.\u0e04._\u0e21\u0e34.\u0e22._\u0e01.\u0e04._\u0e2a.\u0e04._\u0e01.\u0e22._\u0e15.\u0e04._\u0e1e.\u0e22._\u0e18.\u0e04.".split("_"),formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY \u0e40\u0e27\u0e25\u0e32 H:mm",LLLL:"\u0e27\u0e31\u0e19dddd\u0e17\u0e35\u0e48 D MMMM YYYY \u0e40\u0e27\u0e25\u0e32 H:mm"},relativeTime:{future:"\u0e2d\u0e35\u0e01 %s",past:"%s\u0e17\u0e35\u0e48\u0e41\u0e25\u0e49\u0e27",s:"\u0e44\u0e21\u0e48\u0e01\u0e35\u0e48\u0e27\u0e34\u0e19\u0e32\u0e17\u0e35",m:"1 \u0e19\u0e32\u0e17\u0e35",mm:"%d \u0e19\u0e32\u0e17\u0e35",h:"1 \u0e0a\u0e31\u0e48\u0e27\u0e42\u0e21\u0e07",hh:"%d \u0e0a\u0e31\u0e48\u0e27\u0e42\u0e21\u0e07",d:"1 \u0e27\u0e31\u0e19",dd:"%d \u0e27\u0e31\u0e19",M:"1 \u0e40\u0e14\u0e37\u0e2d\u0e19",MM:"%d \u0e40\u0e14\u0e37\u0e2d\u0e19",y:"1 \u0e1b\u0e35",yy:"%d \u0e1b\u0e35"},ordinal:function(_){return _+"."}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/59605.a2f7e321.chunk.js b/ydb/core/viewer/monitoring/static/js/59605.a2f7e321.chunk.js new file mode 100644 index 000000000000..3292b32b2be9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/59605.a2f7e321.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[59605],{51572:e=>{function a(e){!function(e){function a(e,a){return"___"+e.toUpperCase()+a+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(n,t,s,o){if(n.language===t){var i=n.tokenStack=[];n.code=n.code.replace(s,(function(e){if("function"===typeof o&&!o(e))return e;for(var s,r=i.length;-1!==n.code.indexOf(s=a(t,r));)++r;return i[r]=e,s})),n.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(n,t){if(n.language===t&&n.tokenStack){n.grammar=e.languages[t];var s=0,o=Object.keys(n.tokenStack);!function i(r){for(var u=0;u=o.length);u++){var l=r[u];if("string"===typeof l||l.content&&"string"===typeof l.content){var g=o[s],c=n.tokenStack[g],p="string"===typeof l?l:l.content,d=a(t,g),f=p.indexOf(d);if(f>-1){++s;var k=p.substring(0,f),m=new e.Token(t,e.tokenize(c,n.grammar),"language-"+t,c),h=p.substring(f+d.length),b=[];k&&b.push.apply(b,i([k])),b.push(m),h&&b.push.apply(b,i([h])),"string"===typeof l?r.splice.apply(r,[u,1].concat(b)):l.content=b}}else l.content&&i(l.content)}return r}(n.tokens)}}}})}(e)}e.exports=a,a.displayName="markupTemplating",a.aliases=[]},52258:(e,a,n)=>{var t=n(51572);function s(e){e.register(t),function(e){e.languages.ejs={delimiter:{pattern:/^<%[-_=]?|[-_]?%>$/,alias:"punctuation"},comment:/^#[\s\S]*/,"language-javascript":{pattern:/[\s\S]+/,inside:e.languages.javascript}},e.hooks.add("before-tokenize",(function(a){e.languages["markup-templating"].buildPlaceholders(a,"ejs",/<%(?!%)[\s\S]+?%>/g)})),e.hooks.add("after-tokenize",(function(a){e.languages["markup-templating"].tokenizePlaceholders(a,"ejs")})),e.languages.eta=e.languages.ejs}(e)}e.exports=s,s.displayName="ejs",s.aliases=["eta"]},59605:(e,a,n)=>{n.d(a,{default:()=>s});var t=n(52258);const s=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/59748.4682a957.chunk.js b/ydb/core/viewer/monitoring/static/js/59748.4682a957.chunk.js new file mode 100644 index 000000000000..df593794a996 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/59748.4682a957.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 59748.4682a957.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[59748],{59748:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>o,language:()=>r});var o={comments:{lineComment:"'",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"],["addhandler","end addhandler"],["class","end class"],["enum","end enum"],["event","end event"],["function","end function"],["get","end get"],["if","end if"],["interface","end interface"],["module","end module"],["namespace","end namespace"],["operator","end operator"],["property","end property"],["raiseevent","end raiseevent"],["removehandler","end removehandler"],["select","end select"],["set","end set"],["structure","end structure"],["sub","end sub"],["synclock","end synclock"],["try","end try"],["while","end while"],["with","end with"],["using","end using"],["do","loop"],["for","next"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]},{open:"<",close:">",notIn:["string","comment"]}],folding:{markers:{start:new RegExp("^\\s*#Region\\b"),end:new RegExp("^\\s*#End Region\\b")}}},r={defaultToken:"",tokenPostfix:".vb",ignoreCase:!0,brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.array",open:"[",close:"]"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.angle",open:"<",close:">"},{token:"keyword.tag-addhandler",open:"addhandler",close:"end addhandler"},{token:"keyword.tag-class",open:"class",close:"end class"},{token:"keyword.tag-enum",open:"enum",close:"end enum"},{token:"keyword.tag-event",open:"event",close:"end event"},{token:"keyword.tag-function",open:"function",close:"end function"},{token:"keyword.tag-get",open:"get",close:"end get"},{token:"keyword.tag-if",open:"if",close:"end if"},{token:"keyword.tag-interface",open:"interface",close:"end interface"},{token:"keyword.tag-module",open:"module",close:"end module"},{token:"keyword.tag-namespace",open:"namespace",close:"end namespace"},{token:"keyword.tag-operator",open:"operator",close:"end operator"},{token:"keyword.tag-property",open:"property",close:"end property"},{token:"keyword.tag-raiseevent",open:"raiseevent",close:"end raiseevent"},{token:"keyword.tag-removehandler",open:"removehandler",close:"end removehandler"},{token:"keyword.tag-select",open:"select",close:"end select"},{token:"keyword.tag-set",open:"set",close:"end set"},{token:"keyword.tag-structure",open:"structure",close:"end structure"},{token:"keyword.tag-sub",open:"sub",close:"end sub"},{token:"keyword.tag-synclock",open:"synclock",close:"end synclock"},{token:"keyword.tag-try",open:"try",close:"end try"},{token:"keyword.tag-while",open:"while",close:"end while"},{token:"keyword.tag-with",open:"with",close:"end with"},{token:"keyword.tag-using",open:"using",close:"end using"},{token:"keyword.tag-do",open:"do",close:"loop"},{token:"keyword.tag-for",open:"for",close:"next"}],keywords:["AddHandler","AddressOf","Alias","And","AndAlso","As","Async","Boolean","ByRef","Byte","ByVal","Call","Case","Catch","CBool","CByte","CChar","CDate","CDbl","CDec","Char","CInt","Class","CLng","CObj","Const","Continue","CSByte","CShort","CSng","CStr","CType","CUInt","CULng","CUShort","Date","Decimal","Declare","Default","Delegate","Dim","DirectCast","Do","Double","Each","Else","ElseIf","End","EndIf","Enum","Erase","Error","Event","Exit","False","Finally","For","Friend","Function","Get","GetType","GetXMLNamespace","Global","GoSub","GoTo","Handles","If","Implements","Imports","In","Inherits","Integer","Interface","Is","IsNot","Let","Lib","Like","Long","Loop","Me","Mod","Module","MustInherit","MustOverride","MyBase","MyClass","NameOf","Namespace","Narrowing","New","Next","Not","Nothing","NotInheritable","NotOverridable","Object","Of","On","Operator","Option","Optional","Or","OrElse","Out","Overloads","Overridable","Overrides","ParamArray","Partial","Private","Property","Protected","Public","RaiseEvent","ReadOnly","ReDim","RemoveHandler","Resume","Return","SByte","Select","Set","Shadows","Shared","Short","Single","Static","Step","Stop","String","Structure","Sub","SyncLock","Then","Throw","To","True","Try","TryCast","TypeOf","UInteger","ULong","UShort","Using","Variant","Wend","When","While","Widening","With","WithEvents","WriteOnly","Xor"],tagwords:["If","Sub","Select","Try","Class","Enum","Function","Get","Interface","Module","Namespace","Operator","Set","Structure","Using","While","With","Do","Loop","For","Next","Property","Continue","AddHandler","RemoveHandler","Event","RaiseEvent","SyncLock"],symbols:/[=>{function a(e){!function(e){var a="(?:"+[/[a-zA-Z_\x80-\uFFFF][\w\x80-\uFFFF]*/.source,/-?(?:\.\d+|\d+(?:\.\d*)?)/.source,/"[^"\\]*(?:\\[\s\S][^"\\]*)*"/.source,/<(?:[^<>]|(?!)*>/.source].join("|")+")",n={markup:{pattern:/(^<)[\s\S]+(?=>$)/,lookbehind:!0,alias:["language-markup","language-html","language-xml"],inside:e.languages.markup}};function r(e,n){return RegExp(e.replace(//g,(function(){return a})),n)}e.languages.dot={comment:{pattern:/\/\/.*|\/\*[\s\S]*?\*\/|^#.*/m,greedy:!0},"graph-name":{pattern:r(/(\b(?:digraph|graph|subgraph)[ \t\r\n]+)/.source,"i"),lookbehind:!0,greedy:!0,alias:"class-name",inside:n},"attr-value":{pattern:r(/(=[ \t\r\n]*)/.source),lookbehind:!0,greedy:!0,inside:n},"attr-name":{pattern:r(/([\[;, \t\r\n])(?=[ \t\r\n]*=)/.source),lookbehind:!0,greedy:!0,inside:n},keyword:/\b(?:digraph|edge|graph|node|strict|subgraph)\b/i,"compass-point":{pattern:/(:[ \t\r\n]*)(?:[ewc_]|[ns][ew]?)(?![\w\x80-\uFFFF])/,lookbehind:!0,alias:"builtin"},node:{pattern:r(/(^|[^-.\w\x80-\uFFFF\\])/.source),lookbehind:!0,greedy:!0,inside:n},operator:/[=:]|-[->]/,punctuation:/[\[\]{};,]/},e.languages.gv=e.languages.dot}(e)}e.exports=a,a.displayName="dot",a.aliases=["gv"]},59786:(e,a,n)=>{n.d(a,{default:()=>t});var r=n(23569);const t=n.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/5988.38ef363d.chunk.js b/ydb/core/viewer/monitoring/static/js/5988.38ef363d.chunk.js deleted file mode 100644 index d27709bb628e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/5988.38ef363d.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 5988.38ef363d.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[5988],{65988:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>o,language:()=>s});var o={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]}]},s={defaultToken:"",tokenPostfix:".aes",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["contract","library","entrypoint","function","stateful","state","hash","signature","tuple","list","address","string","bool","int","record","datatype","type","option","oracle","oracle_query","Call","Bits","Bytes","Oracle","String","Crypto","Address","Auth","Chain","None","Some","bits","bytes","event","let","map","private","public","true","false","var","if","else","throw"],operators:["=",">","<","!","~","?","::",":","==","<=",">=","!=","&&","||","++","--","+","-","*","/","&","|","^","%","<<",">>",">>>","+=","-=","*=","/=","&=","|=","^=","%=","<<=",">>=",">>>="],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?(@floatsuffix)/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?(@floatsuffix)/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F](@integersuffix)/,"number.hex"],[/0[0-7']*[0-7](@integersuffix)/,"number.octal"],[/0[bB][0-1']*[0-1](@integersuffix)/,"number.binary"],[/\d[\d']*\d(@integersuffix)/,"number"],[/\d(@integersuffix)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/59882.b6def2ca.chunk.js b/ydb/core/viewer/monitoring/static/js/59882.b6def2ca.chunk.js new file mode 100644 index 000000000000..724c5dabb844 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/59882.b6def2ca.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[59882],{59882:function(a,i,n){a.exports=function(a){"use strict";function i(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var n=i(a),_={name:"gd",weekdays:"Did\xf2mhnaich_Diluain_Dim\xe0irt_Diciadain_Diardaoin_Dihaoine_Disathairne".split("_"),months:"Am Faoilleach_An Gearran_Am M\xe0rt_An Giblean_An C\xe8itean_An t-\xd2gmhios_An t-Iuchar_An L\xf9nastal_An t-Sultain_An D\xe0mhair_An t-Samhain_An D\xf9bhlachd".split("_"),weekStart:1,weekdaysShort:"Did_Dil_Dim_Dic_Dia_Dih_Dis".split("_"),monthsShort:"Faoi_Gear_M\xe0rt_Gibl_C\xe8it_\xd2gmh_Iuch_L\xf9n_Sult_D\xe0mh_Samh_D\xf9bh".split("_"),weekdaysMin:"D\xf2_Lu_M\xe0_Ci_Ar_Ha_Sa".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"ann an %s",past:"bho chionn %s",s:"beagan diogan",m:"mionaid",mm:"%d mionaidean",h:"uair",hh:"%d uairean",d:"latha",dd:"%d latha",M:"m\xecos",MM:"%d m\xecosan",y:"bliadhna",yy:"%d bliadhna"}};return n.default.locale(_,null,!0),_}(n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/59908.4f5fa1f6.chunk.js b/ydb/core/viewer/monitoring/static/js/59908.4f5fa1f6.chunk.js new file mode 100644 index 000000000000..7dd26a3731a0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/59908.4f5fa1f6.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[59908],{59908:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"tzm",weekdays:"\u2d30\u2d59\u2d30\u2d4e\u2d30\u2d59_\u2d30\u2d62\u2d4f\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d4f\u2d30\u2d59_\u2d30\u2d3d\u2d54\u2d30\u2d59_\u2d30\u2d3d\u2d61\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d4e\u2d61\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d39\u2d62\u2d30\u2d59".split("_"),months:"\u2d49\u2d4f\u2d4f\u2d30\u2d62\u2d54_\u2d31\u2d55\u2d30\u2d62\u2d55_\u2d4e\u2d30\u2d55\u2d5a_\u2d49\u2d31\u2d54\u2d49\u2d54_\u2d4e\u2d30\u2d62\u2d62\u2d53_\u2d62\u2d53\u2d4f\u2d62\u2d53_\u2d62\u2d53\u2d4d\u2d62\u2d53\u2d63_\u2d56\u2d53\u2d5b\u2d5c_\u2d5b\u2d53\u2d5c\u2d30\u2d4f\u2d31\u2d49\u2d54_\u2d3d\u2d5f\u2d53\u2d31\u2d55_\u2d4f\u2d53\u2d61\u2d30\u2d4f\u2d31\u2d49\u2d54_\u2d37\u2d53\u2d4a\u2d4f\u2d31\u2d49\u2d54".split("_"),weekStart:6,weekdaysShort:"\u2d30\u2d59\u2d30\u2d4e\u2d30\u2d59_\u2d30\u2d62\u2d4f\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d4f\u2d30\u2d59_\u2d30\u2d3d\u2d54\u2d30\u2d59_\u2d30\u2d3d\u2d61\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d4e\u2d61\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d39\u2d62\u2d30\u2d59".split("_"),monthsShort:"\u2d49\u2d4f\u2d4f\u2d30\u2d62\u2d54_\u2d31\u2d55\u2d30\u2d62\u2d55_\u2d4e\u2d30\u2d55\u2d5a_\u2d49\u2d31\u2d54\u2d49\u2d54_\u2d4e\u2d30\u2d62\u2d62\u2d53_\u2d62\u2d53\u2d4f\u2d62\u2d53_\u2d62\u2d53\u2d4d\u2d62\u2d53\u2d63_\u2d56\u2d53\u2d5b\u2d5c_\u2d5b\u2d53\u2d5c\u2d30\u2d4f\u2d31\u2d49\u2d54_\u2d3d\u2d5f\u2d53\u2d31\u2d55_\u2d4f\u2d53\u2d61\u2d30\u2d4f\u2d31\u2d49\u2d54_\u2d37\u2d53\u2d4a\u2d4f\u2d31\u2d49\u2d54".split("_"),weekdaysMin:"\u2d30\u2d59\u2d30\u2d4e\u2d30\u2d59_\u2d30\u2d62\u2d4f\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d4f\u2d30\u2d59_\u2d30\u2d3d\u2d54\u2d30\u2d59_\u2d30\u2d3d\u2d61\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d4e\u2d61\u2d30\u2d59_\u2d30\u2d59\u2d49\u2d39\u2d62\u2d30\u2d59".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"\u2d37\u2d30\u2d37\u2d45 \u2d59 \u2d62\u2d30\u2d4f %s",past:"\u2d62\u2d30\u2d4f %s",s:"\u2d49\u2d4e\u2d49\u2d3d",m:"\u2d4e\u2d49\u2d4f\u2d53\u2d3a",mm:"%d \u2d4e\u2d49\u2d4f\u2d53\u2d3a",h:"\u2d59\u2d30\u2d44\u2d30",hh:"%d \u2d5c\u2d30\u2d59\u2d59\u2d30\u2d44\u2d49\u2d4f",d:"\u2d30\u2d59\u2d59",dd:"%d o\u2d59\u2d59\u2d30\u2d4f",M:"\u2d30\u2d62o\u2d53\u2d54",MM:"%d \u2d49\u2d62\u2d62\u2d49\u2d54\u2d4f",y:"\u2d30\u2d59\u2d33\u2d30\u2d59",yy:"%d \u2d49\u2d59\u2d33\u2d30\u2d59\u2d4f"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/60.85d957cd.chunk.js b/ydb/core/viewer/monitoring/static/js/60.85d957cd.chunk.js deleted file mode 100644 index 17ad8f663e5c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/60.85d957cd.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[60],{40060:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"fa",weekdays:"\u06cc\u06a9\u200c\u0634\u0646\u0628\u0647_\u062f\u0648\u0634\u0646\u0628\u0647_\u0633\u0647\u200c\u0634\u0646\u0628\u0647_\u0686\u0647\u0627\u0631\u0634\u0646\u0628\u0647_\u067e\u0646\u062c\u200c\u0634\u0646\u0628\u0647_\u062c\u0645\u0639\u0647_\u0634\u0646\u0628\u0647".split("_"),weekdaysShort:"\u06cc\u06a9\u200c\u0634\u0646\u0628\u0647_\u062f\u0648\u0634\u0646\u0628\u0647_\u0633\u0647\u200c\u0634\u0646\u0628\u0647_\u0686\u0647\u0627\u0631\u0634\u0646\u0628\u0647_\u067e\u0646\u062c\u200c\u0634\u0646\u0628\u0647_\u062c\u0645\u0639\u0647_\u0634\u0646\u0628\u0647".split("_"),weekdaysMin:"\u06cc_\u062f_\u0633_\u0686_\u067e_\u062c_\u0634".split("_"),weekStart:6,months:"\u0698\u0627\u0646\u0648\u06cc\u0647_\u0641\u0648\u0631\u06cc\u0647_\u0645\u0627\u0631\u0633_\u0622\u0648\u0631\u06cc\u0644_\u0645\u0647_\u0698\u0648\u0626\u0646_\u0698\u0648\u0626\u06cc\u0647_\u0627\u0648\u062a_\u0633\u067e\u062a\u0627\u0645\u0628\u0631_\u0627\u06a9\u062a\u0628\u0631_\u0646\u0648\u0627\u0645\u0628\u0631_\u062f\u0633\u0627\u0645\u0628\u0631".split("_"),monthsShort:"\u0698\u0627\u0646\u0648\u06cc\u0647_\u0641\u0648\u0631\u06cc\u0647_\u0645\u0627\u0631\u0633_\u0622\u0648\u0631\u06cc\u0644_\u0645\u0647_\u0698\u0648\u0626\u0646_\u0698\u0648\u0626\u06cc\u0647_\u0627\u0648\u062a_\u0633\u067e\u062a\u0627\u0645\u0628\u0631_\u0627\u06a9\u062a\u0628\u0631_\u0646\u0648\u0627\u0645\u0628\u0631_\u062f\u0633\u0627\u0645\u0628\u0631".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"\u062f\u0631 %s",past:"%s \u067e\u06cc\u0634",s:"\u0686\u0646\u062f \u062b\u0627\u0646\u06cc\u0647",m:"\u06cc\u06a9 \u062f\u0642\u06cc\u0642\u0647",mm:"%d \u062f\u0642\u06cc\u0642\u0647",h:"\u06cc\u06a9 \u0633\u0627\u0639\u062a",hh:"%d \u0633\u0627\u0639\u062a",d:"\u06cc\u06a9 \u0631\u0648\u0632",dd:"%d \u0631\u0648\u0632",M:"\u06cc\u06a9 \u0645\u0627\u0647",MM:"%d \u0645\u0627\u0647",y:"\u06cc\u06a9 \u0633\u0627\u0644",yy:"%d \u0633\u0627\u0644"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/60110.448cdddf.chunk.js b/ydb/core/viewer/monitoring/static/js/60110.448cdddf.chunk.js new file mode 100644 index 000000000000..a8153c933340 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/60110.448cdddf.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 60110.448cdddf.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[60110],{60110:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>o,language:()=>s});var o={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"""',close:'"""',notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"""',close:'"""'},{open:'"',close:'"'}],folding:{offSide:!0}},s={defaultToken:"invalid",tokenPostfix:".gql",keywords:["null","true","false","query","mutation","subscription","extend","schema","directive","scalar","type","interface","union","enum","input","implements","fragment","on"],typeKeywords:["Int","Float","String","Boolean","ID"],directiveLocations:["SCHEMA","SCALAR","OBJECT","FIELD_DEFINITION","ARGUMENT_DEFINITION","INTERFACE","UNION","ENUM","ENUM_VALUE","INPUT_OBJECT","INPUT_FIELD_DEFINITION","QUERY","MUTATION","SUBSCRIPTION","FIELD","FRAGMENT_DEFINITION","FRAGMENT_SPREAD","INLINE_FRAGMENT","VARIABLE_DEFINITION"],operators:["=","!","?",":","&","|"],symbols:/[=!?:&|]+/,escapes:/\\(?:["\\\/bfnrt]|u[0-9A-Fa-f]{4})/,tokenizer:{root:[[/[a-z_][\w$]*/,{cases:{"@keywords":"keyword","@default":"key.identifier"}}],[/[$][\w$]*/,{cases:{"@keywords":"keyword","@default":"argument.identifier"}}],[/[A-Z][\w\$]*/,{cases:{"@typeKeywords":"keyword","@default":"type.identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/@symbols/,{cases:{"@operators":"operator","@default":""}}],[/@\s*[a-zA-Z_\$][\w\$]*/,{token:"annotation",log:"annotation token: $0"}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/"""/,{token:"string",next:"@mlstring",nextEmbedded:"markdown"}],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,{token:"string.quote",bracket:"@open",next:"@string"}]],mlstring:[[/[^"]+/,"string"],['"""',{token:"string",next:"@pop",nextEmbedded:"@pop"}]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,""],[/#.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6342.a2819c87.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/60110.448cdddf.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6342.a2819c87.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/60110.448cdddf.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/6012.aac08e72.chunk.js b/ydb/core/viewer/monitoring/static/js/6012.aac08e72.chunk.js deleted file mode 100644 index efaf51e2a7c2..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6012.aac08e72.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6012.aac08e72.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6012],{46012:(e,s,o)=>{o.r(s),o.d(s,{conf:()=>n,language:()=>l});var n={brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},l={defaultToken:"",tokenPostfix:".dockerfile",variable:/\${?[\w]+}?/,tokenizer:{root:[{include:"@whitespace"},{include:"@comment"},[/(ONBUILD)(\s+)/,["keyword",""]],[/(ENV)(\s+)([\w]+)/,["keyword","",{token:"variable",next:"@arguments"}]],[/(FROM|MAINTAINER|RUN|EXPOSE|ENV|ADD|ARG|VOLUME|LABEL|USER|WORKDIR|COPY|CMD|STOPSIGNAL|SHELL|HEALTHCHECK|ENTRYPOINT)/,{token:"keyword",next:"@arguments"}]],arguments:[{include:"@whitespace"},{include:"@strings"},[/(@variable)/,{cases:{"@eos":{token:"variable",next:"@popall"},"@default":"variable"}}],[/\\/,{cases:{"@eos":"","@default":""}}],[/./,{cases:{"@eos":{token:"",next:"@popall"},"@default":""}}]],whitespace:[[/\s+/,{cases:{"@eos":{token:"",next:"@popall"},"@default":""}}]],comment:[[/(^#.*$)/,"comment","@popall"]],strings:[[/\\'$/,"","@popall"],[/\\'/,""],[/'$/,"string","@popall"],[/'/,"string","@stringBody"],[/"$/,"string","@popall"],[/"/,"string","@dblStringBody"]],stringBody:[[/[^\\\$']/,{cases:{"@eos":{token:"string",next:"@popall"},"@default":"string"}}],[/\\./,"string.escape"],[/'$/,"string","@popall"],[/'/,"string","@pop"],[/(@variable)/,"variable"],[/\\$/,"string"],[/$/,"string","@popall"]],dblStringBody:[[/[^\\\$"]/,{cases:{"@eos":{token:"string",next:"@popall"},"@default":"string"}}],[/\\./,"string.escape"],[/"$/,"string","@popall"],[/"/,"string","@pop"],[/(@variable)/,"variable"],[/\\$/,"string"],[/$/,"string","@popall"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/60221.8d560e16.chunk.js b/ydb/core/viewer/monitoring/static/js/60221.8d560e16.chunk.js new file mode 100644 index 000000000000..e6705d1f7898 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/60221.8d560e16.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[60221],{60221:function(_,e,d){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var d=e(_),Y={name:"zh-tw",weekdays:"\u661f\u671f\u65e5_\u661f\u671f\u4e00_\u661f\u671f\u4e8c_\u661f\u671f\u4e09_\u661f\u671f\u56db_\u661f\u671f\u4e94_\u661f\u671f\u516d".split("_"),weekdaysShort:"\u9031\u65e5_\u9031\u4e00_\u9031\u4e8c_\u9031\u4e09_\u9031\u56db_\u9031\u4e94_\u9031\u516d".split("_"),weekdaysMin:"\u65e5_\u4e00_\u4e8c_\u4e09_\u56db_\u4e94_\u516d".split("_"),months:"\u4e00\u6708_\u4e8c\u6708_\u4e09\u6708_\u56db\u6708_\u4e94\u6708_\u516d\u6708_\u4e03\u6708_\u516b\u6708_\u4e5d\u6708_\u5341\u6708_\u5341\u4e00\u6708_\u5341\u4e8c\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),ordinal:function(_,e){return"W"===e?_+"\u9031":_+"\u65e5"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5 HH:mm",LLLL:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm",l:"YYYY/M/D",ll:"YYYY\u5e74M\u6708D\u65e5",lll:"YYYY\u5e74M\u6708D\u65e5 HH:mm",llll:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm"},relativeTime:{future:"%s\u5167",past:"%s\u524d",s:"\u5e7e\u79d2",m:"1 \u5206\u9418",mm:"%d \u5206\u9418",h:"1 \u5c0f\u6642",hh:"%d \u5c0f\u6642",d:"1 \u5929",dd:"%d \u5929",M:"1 \u500b\u6708",MM:"%d \u500b\u6708",y:"1 \u5e74",yy:"%d \u5e74"},meridiem:function(_,e){var d=100*_+e;return d<600?"\u51cc\u6668":d<900?"\u65e9\u4e0a":d<1100?"\u4e0a\u5348":d<1300?"\u4e2d\u5348":d<1800?"\u4e0b\u5348":"\u665a\u4e0a"}};return d.default.locale(Y,null,!0),Y}(d(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6030.95d317e6.chunk.js b/ydb/core/viewer/monitoring/static/js/6030.95d317e6.chunk.js deleted file mode 100644 index da8d20d18d94..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6030.95d317e6.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6030],{22983:(e,s,t)=>{t.d(s,{B:()=>d});var i=t(59284),n=t(84476),a=t(84375),l=t(55974),o=t(42829),r=t(60712);function d({children:e,onConfirmAction:s,onConfirmActionSuccess:t,dialogHeader:d,dialogText:c,retryButtonText:u,buttonDisabled:v=!1,buttonView:h="action",buttonTitle:p,buttonClassName:m,withPopover:g=!1,popoverContent:f,popoverPlacement:x="right",popoverDisabled:k=!0}){const[b,y]=i.useState(!1),[j,N]=i.useState(!1),[w,D]=i.useState(!1),I=()=>(0,r.jsx)(n.$,{onClick:()=>y(!0),view:h,disabled:v,loading:!v&&j,className:m,title:p,children:e});return(0,r.jsxs)(i.Fragment,{children:[(0,r.jsx)(l.g,{visible:b,header:d,text:c,withRetry:w,retryButtonText:u,onConfirm:async e=>{N(!0),await s(e)},onConfirmActionSuccess:async()=>{D(!1);try{await(null===t||void 0===t?void 0:t())}finally{N(!1)}},onConfirmActionError:e=>{D((0,o.D)(e)),N(!1)},onClose:()=>{y(!1)}}),g?(0,r.jsx)(a.A,{content:f,placement:x,disabled:k,children:I()}):I()]})}},55974:(e,s,t)=>{t.d(s,{g:()=>f});var i=t(59284),n=t(18677),a=t(71153),l=t(74321),o=t(2198),r=t(99991),d=t(89954),c=t(77506),u=t(48372);const v=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),h=(0,u.g4)("ydb-critical-action-dialog",{en:v});var p=t(60712);const m=(0,c.cn)("ydb-critical-dialog"),g=e=>e.data&&"issues"in e.data&&e.data.issues?(0,p.jsx)(d.O,{hideSeverity:!0,data:e.data}):403===e.status?h("no-rights-error"):e.statusText?e.statusText:h("default-error");function f({visible:e,header:s,text:t,withRetry:d,retryButtonText:c,withCheckBox:u,onClose:v,onConfirm:f,onConfirmActionSuccess:x,onConfirmActionError:k}){const[b,y]=i.useState(!1),[j,N]=i.useState(),[w,D]=i.useState(!1),I=async e=>(y(!0),f(e).then((()=>{x(),v()})).catch((e=>{k(e),N(e)})).finally((()=>{y(!1)})));return(0,p.jsx)(o.l,{open:e,hasCloseButton:!1,className:m(),size:"s",onClose:v,onTransitionExited:()=>{N(void 0),D(!1)},children:j?(0,p.jsxs)(i.Fragment,{children:[(0,p.jsx)(o.l.Header,{caption:s}),(0,p.jsx)(o.l.Body,{className:m("body"),children:(0,p.jsxs)("div",{className:m("body-message",{error:!0}),children:[(0,p.jsx)("span",{className:m("error-icon"),children:(0,p.jsx)(n.A,{width:"24",height:"22"})}),g(j)]})}),(0,p.jsx)(o.l.Footer,{loading:!1,preset:"default",textButtonApply:d?c||h("button-retry"):void 0,textButtonCancel:h("button-close"),onClickButtonApply:()=>I(!0),onClickButtonCancel:v})]}):(0,p.jsxs)(i.Fragment,{children:[(0,p.jsx)(o.l.Header,{caption:s}),(0,p.jsxs)(o.l.Body,{className:m("body"),children:[(0,p.jsxs)("div",{className:m("body-message",{warning:!0}),children:[(0,p.jsx)("span",{className:m("warning-icon"),children:(0,p.jsx)(r.I,{data:a.A,size:24})}),t]}),u?(0,p.jsx)(l.S,{checked:w,onUpdate:D,children:h("checkbox-text")}):null]}),(0,p.jsx)(o.l.Footer,{loading:b,preset:"default",textButtonApply:h("button-confirm"),textButtonCancel:h("button-cancel"),propsButtonApply:{type:"submit",disabled:u&&!w},onClickButtonCancel:v,onClickButtonApply:()=>I()})]})})}},42829:(e,s,t)=>{t.d(s,{D:()=>i});const i=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},3685:(e,s,t)=>{t.d(s,{$:()=>o});var i=t(77506),n=t(33775),a=t(60712);const l=(0,i.cn)("ydb-entity-page-title");function o({entityName:e,status:s,id:t,className:i}){return(0,a.jsxs)("div",{className:l(null,i),children:[(0,a.jsx)("span",{className:l("prefix"),children:e}),(0,a.jsx)(n.k,{className:l("icon"),status:s,size:"s"}),t]})}},42655:(e,s,t)=>{t.d(s,{y:()=>c});var i=t(59284),n=t(89169),a=t(77506),l=t(66781),o=t(60712);const r=(0,a.cn)("ydb-info-viewer-skeleton"),d=()=>(0,o.jsxs)("div",{className:r("label"),children:[(0,o.jsx)(n.E,{className:r("label__text")}),(0,o.jsx)("div",{className:r("label__dots")})]}),c=({rows:e=8,className:s,delay:t=600})=>{const[a]=(0,l.y)(t);let c=(0,o.jsxs)(i.Fragment,{children:[(0,o.jsx)(d,{}),(0,o.jsx)(n.E,{className:r("value")})]});return a||(c=null),(0,o.jsx)("div",{className:r(null,s),children:[...new Array(e)].map(((e,s)=>(0,o.jsx)("div",{className:r("row"),children:c},`skeleton-row-${s}`)))})}},58389:(e,s,t)=>{t.d(s,{B:()=>c});var i=t(87184),n=t(77506),a=t(90053),l=t(70043),o=t(60712);const r=(0,n.cn)("ydb-page-meta");function d({items:e,loading:s}){return(0,o.jsx)("div",{className:r("info"),children:s?(0,o.jsx)(l.E,{className:r("skeleton")}):e.filter((e=>Boolean(e))).join("\xa0\xa0\xb7\xa0\xa0")})}function c({className:e,...s}){return(0,o.jsxs)(i.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:r(null,e),children:[(0,o.jsx)(d,{...s}),(0,o.jsx)(a.E,{})]})}},70043:(e,s,t)=>{t.d(s,{E:()=>l});var i=t(89169),n=t(66781),a=t(60712);const l=({delay:e=600,className:s})=>{const[t]=(0,n.y)(e);return t?(0,a.jsx)(i.E,{className:s}):null}},67440:(e,s,t)=>{t.d(s,{E:()=>y});t(59284);var i=t(92459),n=t(78668),a=t(7435),l=t(77506),o=t(56839),r=t(31684),d=t(7187),c=t(90182),u=t(41650),v=t(60073),h=t(25196),p=t(15132),m=t(33775),g=t(48372);const f=JSON.parse('{"slot-id":"VDisk Slot Id","pool-name":"Storage Pool Name","kind":"Kind","guid":"GUID","incarnation-guid":"Incarnation GUID","instance-guid":"Instance GUID","replication-status":"Replicated","state-status":"VDisk State","space-status":"Disk Space","fresh-rank-satisfaction":"Fresh Rank Satisfaction","level-rank-satisfaction":"Level Rank Satisfaction","front-queues":"Front Queues","has-unreadable-blobs":"Has Unreadable Blobs","size":"Size","read-throughput":"Read Throughput","write-throughput":"Write Throughput","links":"Links","vdisk-page":"VDisk Page","developer-ui":"Developer UI","yes":"Yes","no":"No","vdiks-title":"VDisk"}'),x=(0,g.g4)("ydb-vDisk-info",{en:f});var k=t(60712);const b=(0,l.cn)("ydb-vdisk-info");function y({data:e,withVDiskPageLink:s,withTitle:t,...l}){var d,g;const f=(0,c.N4)(n._5),{AllocatedSize:y,DiskSpace:N,FrontQueues:w,Guid:D,Replicated:I,VDiskState:S,VDiskSlotId:C,Kind:_,SatisfactionRank:A,AvailableSize:E,HasUnreadableBlobs:P,IncarnationGuid:R,InstanceGuid:T,StoragePoolName:B,ReadThroughput:F,WriteThroughput:V,PDiskId:$,NodeId:O}=e||{},L=[];var z,G;((0,a.f8)(C)&&L.push({label:x("slot-id"),value:C}),(0,a.f8)(B)&&L.push({label:x("pool-name"),value:B}),(0,a.f8)(S)&&L.push({label:x("state-status"),value:S}),Number(y)>=0&&Number(E)>=0&&L.push({label:x("size"),value:(0,k.jsx)(p.O,{value:y,capacity:Number(y)+Number(E),formatValues:o.vX,colorizeProgress:!0})}),(0,a.f8)(_)&&L.push({label:x("kind"),value:_}),(0,a.f8)(D)&&L.push({label:x("guid"),value:D}),(0,a.f8)(R)&&L.push({label:x("incarnation-guid"),value:R}),(0,a.f8)(T)&&L.push({label:x("instance-guid"),value:T}),(0,a.f8)(I)&&L.push({label:x("replication-status"),value:x(I?"yes":"no")}),(0,a.f8)(N)&&L.push({label:x("space-status"),value:(0,k.jsx)(m.k,{status:N})}),(0,a.f8)(null===A||void 0===A||null===(d=A.FreshRank)||void 0===d?void 0:d.Flag))&&L.push({label:x("fresh-rank-satisfaction"),value:(0,k.jsx)(m.k,{status:null===A||void 0===A||null===(z=A.FreshRank)||void 0===z?void 0:z.Flag})});(0,a.f8)(null===A||void 0===A||null===(g=A.LevelRank)||void 0===g?void 0:g.Flag)&&L.push({label:x("level-rank-satisfaction"),value:(0,k.jsx)(m.k,{status:null===A||void 0===A||null===(G=A.LevelRank)||void 0===G?void 0:G.Flag})});(0,a.f8)(w)&&L.push({label:x("front-queues"),value:(0,k.jsx)(m.k,{status:w})}),(0,a.f8)(P)&&L.push({label:x("has-unreadable-blobs"),value:x(P?"yes":"no")}),(0,a.f8)(F)&&L.push({label:x("read-throughput"),value:(0,u.O4)(F)}),(0,a.f8)(V)&&L.push({label:x("write-throughput"),value:(0,u.O4)(V)});if((0,a.f8)($)&&(0,a.f8)(O)&&(0,a.f8)(C)){const e=[];if(s){const s=(0,i.yX)(C,$,O);e.push((0,k.jsx)(h.K,{title:x("vdisk-page"),url:s,external:!1},s))}if(f){const s=(0,r.Wg)({nodeId:O,pDiskId:$,vDiskSlotId:C});e.push((0,k.jsx)(h.K,{title:x("developer-ui"),url:s},s))}e.length&&L.push({label:x("links"),value:(0,k.jsx)("div",{className:b("links"),children:e})})}const H=e&&t?(0,k.jsx)(j,{data:e}):null;return(0,k.jsx)(v.z_,{info:L,title:H,...l})}function j({data:e}){return(0,k.jsxs)("div",{className:b("title"),children:[x("vdiks-title"),(0,k.jsx)(m.k,{status:(0,d.XY)(e.Severity)}),e.StringifiedId]})}},89954:(e,s,t)=>{t.d(s,{O:()=>I});var i=t(59284),n=t(45720),a=t(16929),l=t(71153),o=t(18677),r=t(84476),d=t(33705),c=t(67884),u=t(99991),v=t(77506),h=t(48372);const p=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),m=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),g=(0,h.g4)("ydb-shorty-string",{ru:m,en:p});var f=t(60712);const x=(0,v.cn)("kv-shorty-string");function k({value:e="",limit:s=200,strict:t=!1,displayLength:n=!0,render:a=e=>e,onToggle:l,expandLabel:o=g("default_expand_label"),collapseLabel:r=g("default_collapse_label")}){const[d,u]=i.useState(!1),v=(d?r:o)+(n&&!d?g("chars_count",{count:e.length}):""),h=e.length>s+(t?0:v.length),p=d||!h?e:e.slice(0,s-4)+"\xa0...";return(0,f.jsxs)("div",{className:x(),children:[a(p),h?(0,f.jsx)(c.N,{className:x("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),u((e=>!e)),null===l||void 0===l||l()},children:v}):null]})}var b=t(41650);const y=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function j(e){return function(e){return!!e&&void 0!==y[e]}(e)?y[e]:"S_INFO"}const N=(0,v.cn)("kv-result-issues"),w=(0,v.cn)("kv-issues"),D=(0,v.cn)("kv-issue");function I({data:e,hideSeverity:s}){const[t,n]=i.useState(!1),a="string"===typeof e||null===e||void 0===e?void 0:e.issues,l=Array.isArray(a)&&a.length>0;return(0,f.jsxs)("div",{className:N(),children:[(0,f.jsxs)("div",{className:N("error-message"),children:[(()=>{let t;if("string"===typeof e)t=e;else{var n,a;const l=j(null===e||void 0===e||null===(n=e.error)||void 0===n?void 0:n.severity);t=(0,f.jsxs)(i.Fragment,{children:[s?null:(0,f.jsxs)(i.Fragment,{children:[(0,f.jsx)(R,{severity:l})," "]}),(0,f.jsx)("span",{className:N("error-message-text"),children:null===e||void 0===e||null===(a=e.error)||void 0===a?void 0:a.message})]})}return t})(),l&&(0,f.jsx)(r.$,{view:"normal",onClick:()=>n(!t),children:t?"Hide details":"Show details"})]}),l&&t&&(0,f.jsx)(S,{hideSeverity:s,issues:a})]})}function S({issues:e,hideSeverity:s}){const t=null===e||void 0===e?void 0:e.reduce(((e,s)=>{var t;const i=null!==(t=s.severity)&&void 0!==t?t:10;return Math.min(e,i)}),10);return(0,f.jsx)("div",{className:w(null),children:null===e||void 0===e?void 0:e.map(((e,i)=>(0,f.jsx)(C,{hideSeverity:s,issue:e,expanded:e===t},i)))})}function C({issue:e,hideSeverity:s,level:t=0}){const[n,a]=i.useState(!0),l=j(e.severity),o=e.issues,c=Array.isArray(o)&&o.length>0,u=n?"bottom":"right";return(0,f.jsxs)("div",{className:D({leaf:!c,"has-issues":c}),children:[(0,f.jsxs)("div",{className:D("line"),children:[c&&(0,f.jsx)(r.$,{view:"flat-secondary",onClick:()=>a(!n),className:D("arrow-toggle"),children:(0,f.jsx)(d.I,{direction:u,size:16})}),s?null:(0,f.jsx)(R,{severity:l}),(0,f.jsx)(_,{issue:e}),e.issue_code?(0,f.jsxs)("span",{className:D("code"),children:["Code: ",e.issue_code]}):null]}),c&&n&&(0,f.jsx)("div",{className:D("issues"),children:(0,f.jsx)(A,{issues:o,level:t+1,expanded:n})})]})}function _({issue:e}){var s;const t=function(e){const{position:s}=e;if("object"!==typeof s||null===s||!(0,b.kf)(s.row))return"";const{row:t,column:i}=s;return(0,b.kf)(i)?`${t}:${i}`:`line ${t}`}(e),i=window.ydbEditor,n=()=>(0,f.jsxs)("span",{className:D("message"),children:[t&&(0,f.jsx)("span",{className:D("place-text"),title:"Position",children:t}),(0,f.jsx)("div",{className:D("message-text"),children:(0,f.jsx)(k,{value:e.message,expandLabel:"Show full message"})})]}),{row:a,column:l}=null!==(s=e.position)&&void 0!==s?s:{};if(!((0,b.kf)(a)&&i))return n();return(0,f.jsx)(c.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:a,column:null!==l&&void 0!==l?l:0};i.setPosition(e),i.revealPositionInCenterIfOutsideViewport(e),i.focus()},view:"primary",children:n()})}function A(e){const{issues:s,level:t,expanded:i}=e;return(0,f.jsx)("div",{className:D("list"),children:s.map(((e,s)=>(0,f.jsx)(C,{issue:e,level:t,expanded:i},s)))})}const E={S_INFO:n.A,S_WARNING:a.A,S_ERROR:l.A,S_FATAL:o.A},P=(0,v.cn)("yql-issue-severity");function R({severity:e}){const s=e.slice(2).toLowerCase();return(0,f.jsxs)("span",{className:P({severity:s}),children:[(0,f.jsx)(u.I,{className:P("icon"),data:E[e]}),(0,f.jsx)("span",{className:P("title"),children:s})]})}},80208:(e,s,t)=>{t.r(s),t.d(s,{VDiskPage:()=>P});var i=t(59284);const n=e=>i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),i.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M9.28 4.78a.75.75 0 0 0 0-1.06l-2.5-2.5a.75.75 0 1 0-1.06 1.06L6.94 3.5H1.75a.75.75 0 1 0 0 1.5h5.19L5.72 6.22a.75.75 0 1 0 1.06 1.06zm-.06 3.94-2.5 2.5a.75.75 0 0 0 0 1.06l2.5 2.5a.75.75 0 1 0 1.06-1.06L9.06 12.5h5.19a.75.75 0 0 0 0-1.5H9.06l1.22-1.22a.75.75 0 1 0-1.06-1.06M14 4.25a1.75 1.75 0 1 1-3.5 0 1.75 1.75 0 0 1 3.5 0M3.75 13.5a1.75 1.75 0 1 0 0-3.5 1.75 1.75 0 0 0 0 3.5",clipRule:"evenodd"}));var a=t(99991),l=t(44992),o=t(61750),r=t(67087),d=t(22983),c=t(3685),u=t(44508),v=t(42655),h=t(58389),p=t(67440),m=t(21334),g=t(78668),f=t(67028),x=t(40174),k=t(7187),b=t(27295),y=t(78034);const j=m.F.injectEndpoints({endpoints:e=>({getVDiskData:e.query({queryFn:async({nodeId:e,pDiskId:s,vDiskSlotId:t},{signal:i})=>{try{const n=await Promise.all([window.api.viewer.getVDiskInfo({nodeId:e,pDiskId:s,vDiskSlotId:t},{signal:i}),window.api.viewer.getNodeWhiteboardPDiskInfo({nodeId:e,pDiskId:s},{signal:i}),window.api.viewer.getNodeInfo(e,{signal:i})]);return{data:function([e,s,t]){var i,n,a,l,o,r,d;const c=null===(i=e.VDiskStateInfo)||void 0===i?void 0:i[0],u=(0,b.WT)(c),v=null===(n=s.PDiskStateInfo)||void 0===n?void 0:n[0],h=(0,b.or)(v),p=null===(a=t.SystemStateInfo)||void 0===a?void 0:a[0],m=(0,y.q1)(p),g=null!==(l=null!==(o=u.NodeId)&&void 0!==o?o:h.NodeId)&&void 0!==l?l:m.NodeId,f=m.Host,x=null===(r=m.Roles)||void 0===r?void 0:r[0],k=m.DC,j=null!==(d=u.PDiskId)&&void 0!==d?d:h.PDiskId,N=h.Type;return{...u,NodeId:g,NodeHost:f,NodeType:x,NodeDC:k,PDiskId:j,PDiskType:N}}(n)}}catch(n){return{error:n}}},providesTags:(e,s,t)=>["All",{type:"VDiskData",id:(0,k.gh)(t.nodeId,t.pDiskId,t.vDiskSlotId)}]})}),overrideExisting:"throw"});var N=t(7435),w=t(77506),D=t(90182),I=t(99936),S=t(48372);const C=JSON.parse('{"fqdn":"FQDN","node":"Node","pdisk":"PDisk","vdisk":"VDisk","storage":"Storage","evict-vdisk-button":"Evict VDisk","force-evict-vdisk-button":"Evict anyway","evict-vdisk-dialog-header":"Evict VDisk","evict-vdisk-dialog-text":"VDisk will be evicted. Do you want to proceed?","evict-vdisk-not-allowed":"You don\'t have enough rights to evict VDisk"}'),_=(0,S.g4)("ydb-vDisk-page",{en:C});var A=t(60712);const E=(0,w.cn)("ydb-vdisk-page");function P(){const e=(0,D.YQ)(),s=i.useRef(null),t=(0,D.N4)(g._5),b=(0,f.c2)(),[{nodeId:y,pDiskId:w,vDiskSlotId:S}]=(0,r.useQueryParams)({nodeId:r.StringParam,pDiskId:r.StringParam,vDiskSlotId:r.StringParam});i.useEffect((()=>{e((0,x.g)("vDisk",{nodeId:y,pDiskId:w,vDiskSlotId:S}))}),[e,y,w,S]);const[C]=(0,D.Nt)(),P=(0,N.f8)(y)&&(0,N.f8)(w)&&(0,N.f8)(S)?{nodeId:y,pDiskId:w,vDiskSlotId:S}:l.hT,{currentData:R={},isFetching:T,error:B}=j.useGetVDiskDataQuery(P,{pollingInterval:C}),F=T&&void 0===R,{NodeHost:V,NodeId:$,NodeType:O,NodeDC:L,PDiskId:z,PDiskType:G,Severity:H,VDiskId:q}=R,{GroupID:M,GroupGeneration:Y,Ring:U,Domain:W,VDisk:Q}=q||{},J=(0,N.f8)(M)&&(0,N.f8)(Y)&&(0,N.f8)(U)&&(0,N.f8)(W)&&(0,N.f8)(Q),K=async e=>{if(J){var s;const t={groupId:M,groupGeneration:Y,failRealmIdx:U,failDomainIdx:W,vDiskIdx:Q,force:e};let i;if(i=b?await window.api.vdisk.evictVDisk(t):await window.api.tablets.evictVDiskOld(t),!1===(null===(s=i)||void 0===s?void 0:s.result)){throw{statusText:i.error,retryPossible:i.forceRetryPossible}}}},X=()=>{e(m.F.util.invalidateTags([{type:"VDiskData",id:(0,k.gh)(y||0,w||0,S||0)},"StorageData"]))};return(0,A.jsxs)("div",{className:E(null),ref:s,children:[(()=>{const e=S?`${_("vdisk")} ${S}`:_("vdisk"),s=w?`${_("pdisk")} ${w}`:_("pdisk"),t=V||_("node");return(0,A.jsx)(o.mg,{titleTemplate:`%s - ${e} - ${s} \u2014 ${t} \u2014 YDB Monitoring`,defaultTitle:`${e} - ${s} \u2014 ${t} \u2014 YDB Monitoring`})})(),(()=>{const e=V?`${_("fqdn")}: ${V}`:void 0,s=$?`${_("node")}: ${$}`:void 0,t=$?`${_("pdisk")}: ${z}`:void 0;return(0,A.jsx)(h.B,{className:E("meta"),loading:F,items:[e,s,O,L,t,G]})})(),(0,A.jsx)(c.$,{className:E("title"),entityName:_("vdisk"),status:(0,k.XY)(H),id:null===R||void 0===R?void 0:R.StringifiedId}),(0,A.jsx)("div",{className:E("controls"),children:(0,A.jsxs)(d.B,{onConfirmAction:K,onConfirmActionSuccess:X,buttonDisabled:!J||!t,buttonView:"normal",dialogHeader:_("evict-vdisk-dialog-header"),dialogText:_("evict-vdisk-dialog-text"),retryButtonText:_("force-evict-vdisk-button"),withPopover:!0,popoverContent:_("evict-vdisk-not-allowed"),popoverDisabled:t,children:[(0,A.jsx)(a.I,{data:n}),_("evict-vdisk-button")]})}),F?(0,A.jsx)(v.y,{rows:20}):(0,A.jsxs)(i.Fragment,{children:[B?(0,A.jsx)(u.o,{error:B}):null,(0,A.jsx)(p.E,{data:R,className:E("info")}),(0,N.f8)(M)&&(0,N.f8)(y)?(0,A.jsxs)(i.Fragment,{children:[(0,A.jsx)("div",{className:E("storage-title"),children:_("storage")}),(0,A.jsx)(I.z,{groupId:M,nodeId:y,pDiskId:null!==w&&void 0!==w?w:void 0,parentRef:s,viewContext:{groupId:null===M||void 0===M?void 0:M.toString(),nodeId:null===y||void 0===y?void 0:y.toString(),pDiskId:null===w||void 0===w?void 0:w.toString(),vDiskSlotId:null===S||void 0===S?void 0:S.toString()}})]}):null]})]})}},18677:(e,s,t)=>{t.d(s,{A:()=>n});var i=t(59284);const n=e=>i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),i.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},74321:(e,s,t)=>{t.d(s,{S:()=>d});var i=t(59284),n=t(64222),a=t(46898);function l(e){return i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),i.createElement("path",{d:"M4 7h9v3H4z"}))}function o(e){return i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),i.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const r=(0,t(69220).om)("checkbox"),d=i.forwardRef((function(e,s){const{size:t="m",indeterminate:d,disabled:c=!1,content:u,children:v,title:h,style:p,className:m,qa:g}=e,{checked:f,inputProps:x}=(0,n.v)(e),k=u||v,b=i.createElement("span",{className:r("indicator")},i.createElement("span",{className:r("icon"),"aria-hidden":!0},d?i.createElement(l,{className:r("icon-svg",{type:"dash"})}):i.createElement(o,{className:r("icon-svg",{type:"tick"})})),i.createElement("input",Object.assign({},x,{className:r("control")})),i.createElement("span",{className:r("outline")}));return i.createElement(a.m,{ref:s,title:h,style:p,size:t,disabled:c,className:r({size:t,disabled:c,indeterminate:d,checked:f},m),qa:g,control:b},k)}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/60464.c820a295.chunk.js b/ydb/core/viewer/monitoring/static/js/60464.c820a295.chunk.js new file mode 100644 index 000000000000..70ff3556313e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/60464.c820a295.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[60464],{9649:e=>{function n(e){!function(e){function n(e,n){return e.replace(/<<(\d+)>>/g,(function(e,a){return"(?:"+n[+a]+")"}))}function a(e,a,r){return RegExp(n(e,a),r||"")}var r=RegExp("\\b(?:"+("Adj BigInt Bool Ctl Double false Int One Pauli PauliI PauliX PauliY PauliZ Qubit Range Result String true Unit Zero"+" "+"Adjoint adjoint apply as auto body borrow borrowing Controlled controlled distribute elif else fail fixup for function if in internal intrinsic invert is let mutable namespace new newtype open operation repeat return self set until use using while within").trim().replace(/ /g,"|")+")\\b"),t=n(/<<0>>(?:\s*\.\s*<<0>>)*/.source,[/\b[A-Za-z_]\w*\b/.source]),i={keyword:r,punctuation:/[<>()?,.:[\]]/},s=/"(?:\\.|[^\\"])*"/.source;e.languages.qsharp=e.languages.extend("clike",{comment:/\/\/.*/,string:[{pattern:a(/(^|[^$\\])<<0>>/.source,[s]),lookbehind:!0,greedy:!0}],"class-name":[{pattern:a(/(\b(?:as|open)\s+)<<0>>(?=\s*(?:;|as\b))/.source,[t]),lookbehind:!0,inside:i},{pattern:a(/(\bnamespace\s+)<<0>>(?=\s*\{)/.source,[t]),lookbehind:!0,inside:i}],keyword:r,number:/(?:\b0(?:x[\da-f]+|b[01]+|o[0-7]+)|(?:\B\.\d+|\b\d+(?:\.\d*)?)(?:e[-+]?\d+)?)l?\b/i,operator:/\band=|\bor=|\band\b|\bnot\b|\bor\b|<[-=]|[-=]>|>>>=?|<<<=?|\^\^\^=?|\|\|\|=?|&&&=?|w\/=?|~~~|[*\/+\-^=!%]=?/,punctuation:/::|[{}[\];(),.:]/}),e.languages.insertBefore("qsharp","number",{range:{pattern:/\.\./,alias:"operator"}});var o=function(e,n){for(var a=0;a>/g,(function(){return"(?:"+e+")"}));return e.replace(/<>/g,"[^\\s\\S]")}(n(/\{(?:[^"{}]|<<0>>|<>)*\}/.source,[s]),2);e.languages.insertBefore("qsharp","string",{"interpolation-string":{pattern:a(/\$"(?:\\.|<<0>>|[^\\"{])*"/.source,[o]),greedy:!0,inside:{interpolation:{pattern:a(/((?:^|[^\\])(?:\\\\)*)<<0>>/.source,[o]),lookbehind:!0,inside:{punctuation:/^\{|\}$/,expression:{pattern:/[\s\S]+/,alias:"language-qsharp",inside:e.languages.qsharp}}},string:/[\s\S]+/}}})}(e),e.languages.qs=e.languages.qsharp}e.exports=n,n.displayName="qsharp",n.aliases=["qs"]},60464:(e,n,a)=>{a.d(n,{default:()=>t});var r=a(9649);const t=a.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6047.328b41a5.chunk.js b/ydb/core/viewer/monitoring/static/js/6047.328b41a5.chunk.js deleted file mode 100644 index 3a4cf035ce0c..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6047.328b41a5.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6047],{46047:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e);function r(e){return e>1&&e<5&&1!=~~(e/10)}function s(e,n,t,s){var _=e+" ";switch(t){case"s":return n||s?"p\xe1r sekund":"p\xe1r sekundami";case"m":return n?"minuta":s?"minutu":"minutou";case"mm":return n||s?_+(r(e)?"minuty":"minut"):_+"minutami";case"h":return n?"hodina":s?"hodinu":"hodinou";case"hh":return n||s?_+(r(e)?"hodiny":"hodin"):_+"hodinami";case"d":return n||s?"den":"dnem";case"dd":return n||s?_+(r(e)?"dny":"dn\xed"):_+"dny";case"M":return n||s?"m\u011bs\xedc":"m\u011bs\xedcem";case"MM":return n||s?_+(r(e)?"m\u011bs\xedce":"m\u011bs\xedc\u016f"):_+"m\u011bs\xedci";case"y":return n||s?"rok":"rokem";case"yy":return n||s?_+(r(e)?"roky":"let"):_+"lety"}}var _={name:"cs",weekdays:"ned\u011ble_pond\u011bl\xed_\xfater\xfd_st\u0159eda_\u010dtvrtek_p\xe1tek_sobota".split("_"),weekdaysShort:"ne_po_\xfat_st_\u010dt_p\xe1_so".split("_"),weekdaysMin:"ne_po_\xfat_st_\u010dt_p\xe1_so".split("_"),months:"leden_\xfanor_b\u0159ezen_duben_kv\u011bten_\u010derven_\u010dervenec_srpen_z\xe1\u0159\xed_\u0159\xedjen_listopad_prosinec".split("_"),monthsShort:"led_\xfano_b\u0159e_dub_kv\u011b_\u010dvn_\u010dvc_srp_z\xe1\u0159_\u0159\xedj_lis_pro".split("_"),weekStart:1,yearStart:4,ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd D. MMMM YYYY H:mm",l:"D. M. YYYY"},relativeTime:{future:"za %s",past:"p\u0159ed %s",s:s,m:s,mm:s,h:s,hh:s,d:s,dd:s,M:s,MM:s,y:s,yy:s}};return t.default.locale(_,null,!0),_}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/60949.c74a3708.chunk.js b/ydb/core/viewer/monitoring/static/js/60949.c74a3708.chunk.js new file mode 100644 index 000000000000..76748a7a9e66 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/60949.c74a3708.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[60949],{60949:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),s={name:"ms",weekdays:"Ahad_Isnin_Selasa_Rabu_Khamis_Jumaat_Sabtu".split("_"),weekdaysShort:"Ahd_Isn_Sel_Rab_Kha_Jum_Sab".split("_"),weekdaysMin:"Ah_Is_Sl_Rb_Km_Jm_Sb".split("_"),months:"Januari_Februari_Mac_April_Mei_Jun_Julai_Ogos_September_Oktober_November_Disember".split("_"),monthsShort:"Jan_Feb_Mac_Apr_Mei_Jun_Jul_Ogs_Sep_Okt_Nov_Dis".split("_"),weekStart:1,formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH.mm",LLLL:"dddd, D MMMM YYYY HH.mm"},relativeTime:{future:"dalam %s",past:"%s yang lepas",s:"beberapa saat",m:"seminit",mm:"%d minit",h:"sejam",hh:"%d jam",d:"sehari",dd:"%d hari",M:"sebulan",MM:"%d bulan",y:"setahun",yy:"%d tahun"},ordinal:function(e){return e+"."}};return _.default.locale(s,null,!0),s}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61088.c55195af.chunk.js b/ydb/core/viewer/monitoring/static/js/61088.c55195af.chunk.js new file mode 100644 index 000000000000..27d4bc0c4bd0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61088.c55195af.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61088],{61088:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),n={name:"bi",weekdays:"Sande_Mande_Tusde_Wenesde_Tosde_Fraede_Sarade".split("_"),months:"Januari_Februari_Maj_Eprel_Mei_Jun_Julae_Okis_Septemba_Oktoba_Novemba_Disemba".split("_"),weekStart:1,weekdaysShort:"San_Man_Tus_Wen_Tos_Frae_Sar".split("_"),monthsShort:"Jan_Feb_Maj_Epr_Mai_Jun_Jul_Oki_Sep_Okt_Nov_Dis".split("_"),weekdaysMin:"San_Ma_Tu_We_To_Fr_Sar".split("_"),ordinal:function(e){return e},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"lo %s",past:"%s bifo",s:"sam seken",m:"wan minit",mm:"%d minit",h:"wan haoa",hh:"%d haoa",d:"wan dei",dd:"%d dei",M:"wan manis",MM:"%d manis",y:"wan yia",yy:"%d yia"}};return _.default.locale(n,null,!0),n}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6114.c74edf11.chunk.js b/ydb/core/viewer/monitoring/static/js/6114.c74edf11.chunk.js deleted file mode 100644 index 9ae97e429f6f..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6114.c74edf11.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6114],{86114:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),r={name:"fo",weekdays:"sunnudagur_m\xe1nadagur_t\xfdsdagur_mikudagur_h\xf3sdagur_fr\xedggjadagur_leygardagur".split("_"),months:"januar_februar_mars_apr\xedl_mai_juni_juli_august_september_oktober_november_desember".split("_"),weekStart:1,weekdaysShort:"sun_m\xe1n_t\xfds_mik_h\xf3s_fr\xed_ley".split("_"),monthsShort:"jan_feb_mar_apr_mai_jun_jul_aug_sep_okt_nov_des".split("_"),weekdaysMin:"su_m\xe1_t\xfd_mi_h\xf3_fr_le".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D. MMMM, YYYY HH:mm"},relativeTime:{future:"um %s",past:"%s s\xed\xf0ani",s:"f\xe1 sekund",m:"ein minuttur",mm:"%d minuttir",h:"ein t\xedmi",hh:"%d t\xedmar",d:"ein dagur",dd:"%d dagar",M:"ein m\xe1na\xf0ur",MM:"%d m\xe1na\xf0ir",y:"eitt \xe1r",yy:"%d \xe1r"}};return a.default.locale(r,null,!0),r}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61250.2b3f06a3.chunk.js b/ydb/core/viewer/monitoring/static/js/61250.2b3f06a3.chunk.js new file mode 100644 index 000000000000..3c1b711cdc86 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61250.2b3f06a3.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61250],{21035:e=>{function t(e){!function(e){e.languages.agda={comment:/\{-[\s\S]*?(?:-\}|$)|--.*/,string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^\\\r\n"])*"/,greedy:!0},punctuation:/[(){}\u2983\u2984.;@]/,"class-name":{pattern:/((?:data|record) +)\S+/,lookbehind:!0},function:{pattern:/(^[ \t]*)(?!\s)[^:\r\n]+(?=:)/m,lookbehind:!0},operator:{pattern:/(^\s*|\s)(?:[=|:\u2200\u2192\u03bb\\?_]|->)(?=\s)/,lookbehind:!0},keyword:/\b(?:Set|abstract|constructor|data|eta-equality|field|forall|hiding|import|in|inductive|infix|infixl|infixr|instance|let|macro|module|mutual|no-eta-equality|open|overlap|pattern|postulate|primitive|private|public|quote|quoteContext|quoteGoal|quoteTerm|record|renaming|rewrite|syntax|tactic|unquote|unquoteDecl|unquoteDef|using|variable|where|with)\b/}}(e)}e.exports=t,t.displayName="agda",t.aliases=[]},61250:(e,t,a)=>{a.d(t,{default:()=>i});var n=a(21035);const i=a.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61387.f19330bb.chunk.js b/ydb/core/viewer/monitoring/static/js/61387.f19330bb.chunk.js new file mode 100644 index 000000000000..86ea2bb1117a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61387.f19330bb.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61387],{43144:t=>{function e(t){t.languages.ini={comment:{pattern:/(^[ \f\t\v]*)[#;][^\n\r]*/m,lookbehind:!0},section:{pattern:/(^[ \f\t\v]*)\[[^\n\r\]]*\]?/m,lookbehind:!0,inside:{"section-name":{pattern:/(^\[[ \f\t\v]*)[^ \f\t\v\]]+(?:[ \f\t\v]+[^ \f\t\v\]]+)*/,lookbehind:!0,alias:"selector"},punctuation:/\[|\]/}},key:{pattern:/(^[ \f\t\v]*)[^ \f\n\r\t\v=]+(?:[ \f\t\v]+[^ \f\n\r\t\v=]+)*(?=[ \f\t\v]*=)/m,lookbehind:!0,alias:"attr-name"},value:{pattern:/(=[ \f\t\v]*)[^ \f\n\r\t\v]+(?:[ \f\t\v]+[^ \f\n\r\t\v]+)*/,lookbehind:!0,alias:"attr-value",inside:{"inner-value":{pattern:/^("|').+(?=\1$)/,lookbehind:!0}}},punctuation:/=/}}t.exports=e,e.displayName="ini",e.aliases=[]},61387:(t,e,n)=>{n.d(e,{default:()=>i});var a=n(43144);const i=n.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61741.c551cb8f.chunk.js b/ydb/core/viewer/monitoring/static/js/61741.c551cb8f.chunk.js new file mode 100644 index 000000000000..c56c1d9dd059 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61741.c551cb8f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61741],{49166:n=>{function e(n){!function(n){var e={pattern:/\{[\da-f]{8}-[\da-f]{4}-[\da-f]{4}-[\da-f]{4}-[\da-f]{12}\}/i,alias:"constant",inside:{punctuation:/[{}]/}};n.languages["solution-file"]={comment:{pattern:/#.*/,greedy:!0},string:{pattern:/"[^"\r\n]*"|'[^'\r\n]*'/,greedy:!0,inside:{guid:e}},object:{pattern:/^([ \t]*)(?:([A-Z]\w*)\b(?=.*(?:\r\n?|\n)(?:\1[ \t].*(?:\r\n?|\n))*\1End\2(?=[ \t]*$))|End[A-Z]\w*(?=[ \t]*$))/m,lookbehind:!0,greedy:!0,alias:"keyword"},property:{pattern:/^([ \t]*)(?!\s)[^\r\n"#=()]*[^\s"#=()](?=\s*=)/m,lookbehind:!0,inside:{guid:e}},guid:e,number:/\b\d+(?:\.\d+)*\b/,boolean:/\b(?:FALSE|TRUE)\b/,operator:/=/,punctuation:/[(),]/},n.languages.sln=n.languages["solution-file"]}(n)}n.exports=e,e.displayName="solutionFile",e.aliases=[]},61741:(n,e,a)=>{a.d(e,{default:()=>d});var t=a(49166);const d=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61747.0c4ed2d6.chunk.js b/ydb/core/viewer/monitoring/static/js/61747.0c4ed2d6.chunk.js new file mode 100644 index 000000000000..fe3aaccbd33c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61747.0c4ed2d6.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61747],{61747:(e,n,t)=>{t.d(n,{default:()=>a});var r=t(98836);const a=t.n(r)()},90160:e=>{function n(e){!function(e){e.languages.ruby=e.languages.extend("clike",{comment:{pattern:/#.*|^=begin\s[\s\S]*?^=end/m,greedy:!0},"class-name":{pattern:/(\b(?:class|module)\s+|\bcatch\s+\()[\w.\\]+|\b[A-Z_]\w*(?=\s*\.\s*new\b)/,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:BEGIN|END|alias|and|begin|break|case|class|def|define_method|defined|do|each|else|elsif|end|ensure|extend|for|if|in|include|module|new|next|nil|not|or|prepend|private|protected|public|raise|redo|require|rescue|retry|return|self|super|then|throw|undef|unless|until|when|while|yield)\b/,operator:/\.{2,3}|&\.|===||[!=]?~|(?:&&|\|\||<<|>>|\*\*|[+\-*/%<>!^&|=])=?|[?:]/,punctuation:/[(){}[\].,;]/}),e.languages.insertBefore("ruby","operator",{"double-colon":{pattern:/::/,alias:"punctuation"}});var n={pattern:/((?:^|[^\\])(?:\\{2})*)#\{(?:[^{}]|\{[^{}]*\})*\}/,lookbehind:!0,inside:{content:{pattern:/^(#\{)[\s\S]+(?=\}$)/,lookbehind:!0,inside:e.languages.ruby},delimiter:{pattern:/^#\{|\}$/,alias:"punctuation"}}};delete e.languages.ruby.function;var t="(?:"+[/([^a-zA-Z0-9\s{(\[<=])(?:(?!\1)[^\\]|\\[\s\S])*\1/.source,/\((?:[^()\\]|\\[\s\S]|\((?:[^()\\]|\\[\s\S])*\))*\)/.source,/\{(?:[^{}\\]|\\[\s\S]|\{(?:[^{}\\]|\\[\s\S])*\})*\}/.source,/\[(?:[^\[\]\\]|\\[\s\S]|\[(?:[^\[\]\\]|\\[\s\S])*\])*\]/.source,/<(?:[^<>\\]|\\[\s\S]|<(?:[^<>\\]|\\[\s\S])*>)*>/.source].join("|")+")",r=/(?:"(?:\\.|[^"\\\r\n])*"|(?:\b[a-zA-Z_]\w*|[^\s\0-\x7F]+)[?!]?|\$.)/.source;e.languages.insertBefore("ruby","keyword",{"regex-literal":[{pattern:RegExp(/%r/.source+t+/[egimnosux]{0,6}/.source),greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}},{pattern:/(^|[^/])\/(?!\/)(?:\[[^\r\n\]]+\]|\\.|[^[/\\\r\n])+\/[egimnosux]{0,6}(?=\s*(?:$|[\r\n,.;})#]))/,lookbehind:!0,greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}}],variable:/[@$]+[a-zA-Z_]\w*(?:[?!]|\b)/,symbol:[{pattern:RegExp(/(^|[^:]):/.source+r),lookbehind:!0,greedy:!0},{pattern:RegExp(/([\r\n{(,][ \t]*)/.source+r+/(?=:(?!:))/.source),lookbehind:!0,greedy:!0}],"method-definition":{pattern:/(\bdef\s+)\w+(?:\s*\.\s*\w+)?/,lookbehind:!0,inside:{function:/\b\w+$/,keyword:/^self\b/,"class-name":/^\w+/,punctuation:/\./}}}),e.languages.insertBefore("ruby","string",{"string-literal":[{pattern:RegExp(/%[qQiIwWs]?/.source+t),greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/("|')(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|(?!\1)[^\\#\r\n])*\1/,greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?([a-z_]\w*)[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?[a-z_]\w*|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?/}},interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?'([a-z_]\w*)'[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?'[a-z_]\w*'|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?'|'$/}},string:/[\s\S]+/}}],"command-literal":[{pattern:RegExp(/%x/.source+t),greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}},{pattern:/`(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|[^\\`#\r\n])*`/,greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}}]}),delete e.languages.ruby.string,e.languages.insertBefore("ruby","number",{builtin:/\b(?:Array|Bignum|Binding|Class|Continuation|Dir|Exception|FalseClass|File|Fixnum|Float|Hash|IO|Integer|MatchData|Method|Module|NilClass|Numeric|Object|Proc|Range|Regexp|Stat|String|Struct|Symbol|TMS|Thread|ThreadGroup|Time|TrueClass)\b/,constant:/\b[A-Z][A-Z0-9_]*(?:[?!]|\b)/}),e.languages.rb=e.languages.ruby}(e)}e.exports=n,n.displayName="ruby",n.aliases=["rb"]},98836:(e,n,t)=>{var r=t(90160);function a(e){e.register(r),function(e){e.languages.crystal=e.languages.extend("ruby",{keyword:[/\b(?:__DIR__|__END_LINE__|__FILE__|__LINE__|abstract|alias|annotation|as|asm|begin|break|case|class|def|do|else|elsif|end|ensure|enum|extend|for|fun|if|ifdef|include|instance_sizeof|lib|macro|module|next|of|out|pointerof|private|protected|ptr|require|rescue|return|select|self|sizeof|struct|super|then|type|typeof|undef|uninitialized|union|unless|until|when|while|with|yield)\b/,{pattern:/(\.\s*)(?:is_a|responds_to)\?/,lookbehind:!0}],number:/\b(?:0b[01_]*[01]|0o[0-7_]*[0-7]|0x[\da-fA-F_]*[\da-fA-F]|(?:\d(?:[\d_]*\d)?)(?:\.[\d_]*\d)?(?:[eE][+-]?[\d_]*\d)?)(?:_(?:[uif](?:8|16|32|64))?)?\b/,operator:[/->/,e.languages.ruby.operator],punctuation:/[(){}[\].,;\\]/}),e.languages.insertBefore("crystal","string-literal",{attribute:{pattern:/@\[.*?\]/,inside:{delimiter:{pattern:/^@\[|\]$/,alias:"punctuation"},attribute:{pattern:/^(\s*)\w+/,lookbehind:!0,alias:"class-name"},args:{pattern:/\S(?:[\s\S]*\S)?/,inside:e.languages.crystal}}},expansion:{pattern:/\{(?:\{.*?\}|%.*?%)\}/,inside:{content:{pattern:/^(\{.)[\s\S]+(?=.\}$)/,lookbehind:!0,inside:e.languages.crystal},delimiter:{pattern:/^\{[\{%]|[\}%]\}$/,alias:"operator"}}},char:{pattern:/'(?:[^\\\r\n]{1,2}|\\(?:.|u(?:[A-Fa-f0-9]{1,4}|\{[A-Fa-f0-9]{1,6}\})))'/,greedy:!0}})}(e)}e.exports=a,a.displayName="crystal",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61865.21725853.chunk.js b/ydb/core/viewer/monitoring/static/js/61865.21725853.chunk.js new file mode 100644 index 000000000000..6132aac38f93 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61865.21725853.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61865],{61865:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ka",weekdays:"\u10d9\u10d5\u10d8\u10e0\u10d0_\u10dd\u10e0\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10e1\u10d0\u10db\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10dd\u10d7\u10ee\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10ee\u10e3\u10d7\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8_\u10de\u10d0\u10e0\u10d0\u10e1\u10d9\u10d4\u10d5\u10d8_\u10e8\u10d0\u10d1\u10d0\u10d7\u10d8".split("_"),weekdaysShort:"\u10d9\u10d5\u10d8_\u10dd\u10e0\u10e8_\u10e1\u10d0\u10db_\u10dd\u10d7\u10ee_\u10ee\u10e3\u10d7_\u10de\u10d0\u10e0_\u10e8\u10d0\u10d1".split("_"),weekdaysMin:"\u10d9\u10d5_\u10dd\u10e0_\u10e1\u10d0_\u10dd\u10d7_\u10ee\u10e3_\u10de\u10d0_\u10e8\u10d0".split("_"),months:"\u10d8\u10d0\u10dc\u10d5\u10d0\u10e0\u10d8_\u10d7\u10d4\u10d1\u10d4\u10e0\u10d5\u10d0\u10da\u10d8_\u10db\u10d0\u10e0\u10e2\u10d8_\u10d0\u10de\u10e0\u10d8\u10da\u10d8_\u10db\u10d0\u10d8\u10e1\u10d8_\u10d8\u10d5\u10dc\u10d8\u10e1\u10d8_\u10d8\u10d5\u10da\u10d8\u10e1\u10d8_\u10d0\u10d2\u10d5\u10d8\u10e1\u10e2\u10dd_\u10e1\u10d4\u10e5\u10e2\u10d4\u10db\u10d1\u10d4\u10e0\u10d8_\u10dd\u10e5\u10e2\u10dd\u10db\u10d1\u10d4\u10e0\u10d8_\u10dc\u10dd\u10d4\u10db\u10d1\u10d4\u10e0\u10d8_\u10d3\u10d4\u10d9\u10d4\u10db\u10d1\u10d4\u10e0\u10d8".split("_"),monthsShort:"\u10d8\u10d0\u10dc_\u10d7\u10d4\u10d1_\u10db\u10d0\u10e0_\u10d0\u10de\u10e0_\u10db\u10d0\u10d8_\u10d8\u10d5\u10dc_\u10d8\u10d5\u10da_\u10d0\u10d2\u10d5_\u10e1\u10d4\u10e5_\u10dd\u10e5\u10e2_\u10dc\u10dd\u10d4_\u10d3\u10d4\u10d9".split("_"),weekStart:1,formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"%s \u10e8\u10d4\u10db\u10d3\u10d4\u10d2",past:"%s \u10ec\u10d8\u10dc",s:"\u10ec\u10d0\u10db\u10d8",m:"\u10ec\u10e3\u10d7\u10d8",mm:"%d \u10ec\u10e3\u10d7\u10d8",h:"\u10e1\u10d0\u10d0\u10d7\u10d8",hh:"%d \u10e1\u10d0\u10d0\u10d7\u10d8\u10e1",d:"\u10d3\u10e6\u10d4\u10e1",dd:"%d \u10d3\u10e6\u10d8\u10e1 \u10d2\u10d0\u10dc\u10db\u10d0\u10d5\u10da\u10dd\u10d1\u10d0\u10e8\u10d8",M:"\u10d7\u10d5\u10d8\u10e1",MM:"%d \u10d7\u10d5\u10d8\u10e1",y:"\u10ec\u10d4\u10da\u10d8",yy:"%d \u10ec\u10da\u10d8\u10e1"},ordinal:function(_){return _}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/61917.92d39b4c.chunk.js b/ydb/core/viewer/monitoring/static/js/61917.92d39b4c.chunk.js new file mode 100644 index 000000000000..ece8cf47c9f6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/61917.92d39b4c.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[61917],{61917:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"hy-am",weekdays:"\u056f\u056b\u0580\u0561\u056f\u056b_\u0565\u0580\u056f\u0578\u0582\u0577\u0561\u0562\u0569\u056b_\u0565\u0580\u0565\u0584\u0577\u0561\u0562\u0569\u056b_\u0579\u0578\u0580\u0565\u0584\u0577\u0561\u0562\u0569\u056b_\u0570\u056b\u0576\u0563\u0577\u0561\u0562\u0569\u056b_\u0578\u0582\u0580\u0562\u0561\u0569_\u0577\u0561\u0562\u0561\u0569".split("_"),months:"\u0570\u0578\u0582\u0576\u057e\u0561\u0580\u056b_\u0583\u0565\u057f\u0580\u057e\u0561\u0580\u056b_\u0574\u0561\u0580\u057f\u056b_\u0561\u057a\u0580\u056b\u056c\u056b_\u0574\u0561\u0575\u056b\u057d\u056b_\u0570\u0578\u0582\u0576\u056b\u057d\u056b_\u0570\u0578\u0582\u056c\u056b\u057d\u056b_\u0585\u0563\u0578\u057d\u057f\u0578\u057d\u056b_\u057d\u0565\u057a\u057f\u0565\u0574\u0562\u0565\u0580\u056b_\u0570\u0578\u056f\u057f\u0565\u0574\u0562\u0565\u0580\u056b_\u0576\u0578\u0575\u0565\u0574\u0562\u0565\u0580\u056b_\u0564\u0565\u056f\u057f\u0565\u0574\u0562\u0565\u0580\u056b".split("_"),weekStart:1,weekdaysShort:"\u056f\u0580\u056f_\u0565\u0580\u056f_\u0565\u0580\u0584_\u0579\u0580\u0584_\u0570\u0576\u0563_\u0578\u0582\u0580\u0562_\u0577\u0562\u0569".split("_"),monthsShort:"\u0570\u0576\u057e_\u0583\u057f\u0580_\u0574\u0580\u057f_\u0561\u057a\u0580_\u0574\u0575\u057d_\u0570\u0576\u057d_\u0570\u056c\u057d_\u0585\u0563\u057d_\u057d\u057a\u057f_\u0570\u056f\u057f_\u0576\u0574\u0562_\u0564\u056f\u057f".split("_"),weekdaysMin:"\u056f\u0580\u056f_\u0565\u0580\u056f_\u0565\u0580\u0584_\u0579\u0580\u0584_\u0570\u0576\u0563_\u0578\u0582\u0580\u0562_\u0577\u0562\u0569".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY \u0569.",LLL:"D MMMM YYYY \u0569., HH:mm",LLLL:"dddd, D MMMM YYYY \u0569., HH:mm"},relativeTime:{future:"%s \u0570\u0565\u057f\u0578",past:"%s \u0561\u057c\u0561\u057b",s:"\u0574\u056b \u0584\u0561\u0576\u056b \u057e\u0561\u0575\u0580\u056f\u0575\u0561\u0576",m:"\u0580\u0578\u057a\u0565",mm:"%d \u0580\u0578\u057a\u0565",h:"\u056a\u0561\u0574",hh:"%d \u056a\u0561\u0574",d:"\u0585\u0580",dd:"%d \u0585\u0580",M:"\u0561\u0574\u056b\u057d",MM:"%d \u0561\u0574\u056b\u057d",y:"\u057f\u0561\u0580\u056b",yy:"%d \u057f\u0561\u0580\u056b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6197.acb1fd7c.chunk.js b/ydb/core/viewer/monitoring/static/js/6197.acb1fd7c.chunk.js new file mode 100644 index 000000000000..a374dd30276b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/6197.acb1fd7c.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6197],{1464:r=>{function e(r){r.languages.asmatmel={comment:{pattern:/;.*/,greedy:!0},string:{pattern:/(["'`])(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0},constant:/\b(?:PORT[A-Z]|DDR[A-Z]|(?:DD|P)[A-Z](?:\d|[0-2]\d|3[01]))\b/,directive:{pattern:/\.\w+(?= )/,alias:"property"},"r-register":{pattern:/\br(?:\d|[12]\d|3[01])\b/,alias:"variable"},"op-code":{pattern:/\b(?:ADC|ADD|ADIW|AND|ANDI|ASR|BCLR|BLD|BRBC|BRBS|BRCC|BRCS|BREAK|BREQ|BRGE|BRHC|BRHS|BRID|BRIE|BRLO|BRLT|BRMI|BRNE|BRPL|BRSH|BRTC|BRTS|BRVC|BRVS|BSET|BST|CALL|CBI|CBR|CLC|CLH|CLI|CLN|CLR|CLS|CLT|CLV|CLZ|COM|CP|CPC|CPI|CPSE|DEC|DES|EICALL|EIJMP|ELPM|EOR|FMUL|FMULS|FMULSU|ICALL|IJMP|IN|INC|JMP|LAC|LAS|LAT|LD|LD[A-Za-z0-9]|LPM|LSL|LSR|MOV|MOVW|MUL|MULS|MULSU|NEG|NOP|OR|ORI|OUT|POP|PUSH|RCALL|RET|RETI|RJMP|ROL|ROR|SBC|SBCI|SBI|SBIC|SBIS|SBIW|SBR|SBRC|SBRS|SEC|SEH|SEI|SEN|SER|SES|SET|SEV|SEZ|SLEEP|SPM|ST|ST[A-Z0-9]|SUB|SUBI|SWAP|TST|WDR|XCH|adc|add|adiw|and|andi|asr|bclr|bld|brbc|brbs|brcc|brcs|break|breq|brge|brhc|brhs|brid|brie|brlo|brlt|brmi|brne|brpl|brsh|brtc|brts|brvc|brvs|bset|bst|call|cbi|cbr|clc|clh|cli|cln|clr|cls|clt|clv|clz|com|cp|cpc|cpi|cpse|dec|des|eicall|eijmp|elpm|eor|fmul|fmuls|fmulsu|icall|ijmp|in|inc|jmp|lac|las|lat|ld|ld[a-z0-9]|lpm|lsl|lsr|mov|movw|mul|muls|mulsu|neg|nop|or|ori|out|pop|push|rcall|ret|reti|rjmp|rol|ror|sbc|sbci|sbi|sbic|sbis|sbiw|sbr|sbrc|sbrs|sec|seh|sei|sen|ser|ses|set|sev|sez|sleep|spm|st|st[a-zA-Z0-9]|sub|subi|swap|tst|wdr|xch)\b/,alias:"keyword"},"hex-number":{pattern:/#?\$[\da-f]{2,4}\b/i,alias:"number"},"binary-number":{pattern:/#?%[01]+\b/,alias:"number"},"decimal-number":{pattern:/#?\b\d+\b/,alias:"number"},register:{pattern:/\b[acznvshtixy]\b/i,alias:"variable"},operator:/>>=?|<<=?|&&?|\|\|?|[-+*/%&|^!=<>?]=?/,punctuation:/[(),:]/}}r.exports=e,e.displayName="asmatmel",e.aliases=[]},6197:(r,e,s)=>{s.d(e,{default:()=>a});var b=s(1464);const a=s.n(b)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/62042.e21d383b.chunk.js b/ydb/core/viewer/monitoring/static/js/62042.e21d383b.chunk.js new file mode 100644 index 000000000000..808e5fab8173 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/62042.e21d383b.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 62042.e21d383b.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[62042],{62042:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>i,language:()=>_});var i={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{markers:{start:new RegExp("^\\s*#pragma\\s+region\\b"),end:new RegExp("^\\s*#pragma\\s+endregion\\b")}}},_={defaultToken:"",tokenPostfix:".cpp",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["abstract","amp","array","auto","bool","break","case","catch","char","class","const","constexpr","const_cast","continue","cpu","decltype","default","delegate","delete","do","double","dynamic_cast","each","else","enum","event","explicit","export","extern","false","final","finally","float","for","friend","gcnew","generic","goto","if","in","initonly","inline","int","interface","interior_ptr","internal","literal","long","mutable","namespace","new","noexcept","nullptr","__nullptr","operator","override","partial","pascal","pin_ptr","private","property","protected","public","ref","register","reinterpret_cast","restrict","return","safe_cast","sealed","short","signed","sizeof","static","static_assert","static_cast","struct","switch","template","this","thread_local","throw","tile_static","true","try","typedef","typeid","typename","union","unsigned","using","virtual","void","volatile","wchar_t","where","while","_asm","_based","_cdecl","_declspec","_fastcall","_if_exists","_if_not_exists","_inline","_multiple_inheritance","_pascal","_single_inheritance","_stdcall","_virtual_inheritance","_w64","__abstract","__alignof","__asm","__assume","__based","__box","__builtin_alignof","__cdecl","__clrcall","__declspec","__delegate","__event","__except","__fastcall","__finally","__forceinline","__gc","__hook","__identifier","__if_exists","__if_not_exists","__inline","__int128","__int16","__int32","__int64","__int8","__interface","__leave","__m128","__m128d","__m128i","__m256","__m256d","__m256i","__m512","__m512d","__m512i","__m64","__multiple_inheritance","__newslot","__nogc","__noop","__nounwind","__novtordisp","__pascal","__pin","__pragma","__property","__ptr32","__ptr64","__raise","__restrict","__resume","__sealed","__single_inheritance","__stdcall","__super","__thiscall","__try","__try_cast","__typeof","__unaligned","__unhook","__uuidof","__value","__virtual_inheritance","__w64","__wchar_t"],operators:["=",">","<","!","~","?",":","==","<=",">=","!=","&&","||","++","--","+","-","*","/","&","|","^","%","<<",">>","+=","-=","*=","/=","&=","|=","^=","%=","<<=",">>="],symbols:/[=>\[\]]/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?(@floatsuffix)/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?(@floatsuffix)/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F](@integersuffix)/,"number.hex"],[/0[0-7']*[0-7](@integersuffix)/,"number.octal"],[/0[bB][0-1']*[0-1](@integersuffix)/,"number.binary"],[/\d[\d']*\d(@integersuffix)/,"number"],[/\d(@integersuffix)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*\\$/,"comment","@linecomment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],linecomment:[[/.*[^\\]$/,"comment","@pop"],[/[^]+/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],raw:[[/[^)]+/,"string.raw"],[/\)$S2\"/,{token:"string.raw.end",next:"@pop"}],[/\)/,"string.raw"]],annotation:[{include:"@whitespace"},[/using|alignas/,"keyword"],[/[a-zA-Z0-9_]+/,"annotation"],[/[,:]/,"delimiter"],[/[()]/,"@brackets"],[/\]\s*\]/,{token:"annotation",next:"@pop"}]],include:[[/(\s*)(<)([^<>]*)(>)/,["","keyword.directive.include.begin","string.include.identifier",{token:"keyword.directive.include.end",next:"@pop"}]],[/(\s*)(")([^"]*)(")/,["","keyword.directive.include.begin","string.include.identifier",{token:"keyword.directive.include.end",next:"@pop"}]]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6374.be0c5879.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/62042.e21d383b.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6374.be0c5879.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/62042.e21d383b.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/6210.69d6a30a.chunk.js b/ydb/core/viewer/monitoring/static/js/6210.69d6a30a.chunk.js deleted file mode 100644 index 3bdb99697794..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6210.69d6a30a.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6210.69d6a30a.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6210],{16210:(E,T,S)=>{S.r(T),S.d(T,{conf:()=>R,language:()=>_});var R={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},_={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ACCESSIBLE","ADD","ALL","ALTER","ANALYZE","AND","AS","ASC","ASENSITIVE","BEFORE","BETWEEN","BIGINT","BINARY","BLOB","BOTH","BY","CALL","CASCADE","CASE","CHANGE","CHAR","CHARACTER","CHECK","COLLATE","COLUMN","CONDITION","CONSTRAINT","CONTINUE","CONVERT","CREATE","CROSS","CUBE","CUME_DIST","CURRENT_DATE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURSOR","DATABASE","DATABASES","DAY_HOUR","DAY_MICROSECOND","DAY_MINUTE","DAY_SECOND","DEC","DECIMAL","DECLARE","DEFAULT","DELAYED","DELETE","DENSE_RANK","DESC","DESCRIBE","DETERMINISTIC","DISTINCT","DISTINCTROW","DIV","DOUBLE","DROP","DUAL","EACH","ELSE","ELSEIF","EMPTY","ENCLOSED","ESCAPED","EXCEPT","EXISTS","EXIT","EXPLAIN","FALSE","FETCH","FIRST_VALUE","FLOAT","FLOAT4","FLOAT8","FOR","FORCE","FOREIGN","FROM","FULLTEXT","FUNCTION","GENERATED","GET","GRANT","GROUP","GROUPING","GROUPS","HAVING","HIGH_PRIORITY","HOUR_MICROSECOND","HOUR_MINUTE","HOUR_SECOND","IF","IGNORE","IN","INDEX","INFILE","INNER","INOUT","INSENSITIVE","INSERT","INT","INT1","INT2","INT3","INT4","INT8","INTEGER","INTERVAL","INTO","IO_AFTER_GTIDS","IO_BEFORE_GTIDS","IS","ITERATE","JOIN","JSON_TABLE","KEY","KEYS","KILL","LAG","LAST_VALUE","LATERAL","LEAD","LEADING","LEAVE","LEFT","LIKE","LIMIT","LINEAR","LINES","LOAD","LOCALTIME","LOCALTIMESTAMP","LOCK","LONG","LONGBLOB","LONGTEXT","LOOP","LOW_PRIORITY","MASTER_BIND","MASTER_SSL_VERIFY_SERVER_CERT","MATCH","MAXVALUE","MEDIUMBLOB","MEDIUMINT","MEDIUMTEXT","MIDDLEINT","MINUTE_MICROSECOND","MINUTE_SECOND","MOD","MODIFIES","NATURAL","NOT","NO_WRITE_TO_BINLOG","NTH_VALUE","NTILE","NULL","NUMERIC","OF","ON","OPTIMIZE","OPTIMIZER_COSTS","OPTION","OPTIONALLY","OR","ORDER","OUT","OUTER","OUTFILE","OVER","PARTITION","PERCENT_RANK","PRECISION","PRIMARY","PROCEDURE","PURGE","RANGE","RANK","READ","READS","READ_WRITE","REAL","RECURSIVE","REFERENCES","REGEXP","RELEASE","RENAME","REPEAT","REPLACE","REQUIRE","RESIGNAL","RESTRICT","RETURN","REVOKE","RIGHT","RLIKE","ROW","ROWS","ROW_NUMBER","SCHEMA","SCHEMAS","SECOND_MICROSECOND","SELECT","SENSITIVE","SEPARATOR","SET","SHOW","SIGNAL","SMALLINT","SPATIAL","SPECIFIC","SQL","SQLEXCEPTION","SQLSTATE","SQLWARNING","SQL_BIG_RESULT","SQL_CALC_FOUND_ROWS","SQL_SMALL_RESULT","SSL","STARTING","STORED","STRAIGHT_JOIN","SYSTEM","TABLE","TERMINATED","THEN","TINYBLOB","TINYINT","TINYTEXT","TO","TRAILING","TRIGGER","TRUE","UNDO","UNION","UNIQUE","UNLOCK","UNSIGNED","UPDATE","USAGE","USE","USING","UTC_DATE","UTC_TIME","UTC_TIMESTAMP","VALUES","VARBINARY","VARCHAR","VARCHARACTER","VARYING","VIRTUAL","WHEN","WHERE","WHILE","WINDOW","WITH","WRITE","XOR","YEAR_MONTH","ZEROFILL"],operators:["AND","BETWEEN","IN","LIKE","NOT","OR","IS","NULL","INTERSECT","UNION","INNER","JOIN","LEFT","OUTER","RIGHT"],builtinFunctions:["ABS","ACOS","ADDDATE","ADDTIME","AES_DECRYPT","AES_ENCRYPT","ANY_VALUE","Area","AsBinary","AsWKB","ASCII","ASIN","AsText","AsWKT","ASYMMETRIC_DECRYPT","ASYMMETRIC_DERIVE","ASYMMETRIC_ENCRYPT","ASYMMETRIC_SIGN","ASYMMETRIC_VERIFY","ATAN","ATAN2","ATAN","AVG","BENCHMARK","BIN","BIT_AND","BIT_COUNT","BIT_LENGTH","BIT_OR","BIT_XOR","Buffer","CAST","CEIL","CEILING","Centroid","CHAR","CHAR_LENGTH","CHARACTER_LENGTH","CHARSET","COALESCE","COERCIBILITY","COLLATION","COMPRESS","CONCAT","CONCAT_WS","CONNECTION_ID","Contains","CONV","CONVERT","CONVERT_TZ","ConvexHull","COS","COT","COUNT","CRC32","CREATE_ASYMMETRIC_PRIV_KEY","CREATE_ASYMMETRIC_PUB_KEY","CREATE_DH_PARAMETERS","CREATE_DIGEST","Crosses","CUME_DIST","CURDATE","CURRENT_DATE","CURRENT_ROLE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURTIME","DATABASE","DATE","DATE_ADD","DATE_FORMAT","DATE_SUB","DATEDIFF","DAY","DAYNAME","DAYOFMONTH","DAYOFWEEK","DAYOFYEAR","DECODE","DEFAULT","DEGREES","DES_DECRYPT","DES_ENCRYPT","DENSE_RANK","Dimension","Disjoint","Distance","ELT","ENCODE","ENCRYPT","EndPoint","Envelope","Equals","EXP","EXPORT_SET","ExteriorRing","EXTRACT","ExtractValue","FIELD","FIND_IN_SET","FIRST_VALUE","FLOOR","FORMAT","FORMAT_BYTES","FORMAT_PICO_TIME","FOUND_ROWS","FROM_BASE64","FROM_DAYS","FROM_UNIXTIME","GEN_RANGE","GEN_RND_EMAIL","GEN_RND_PAN","GEN_RND_SSN","GEN_RND_US_PHONE","GeomCollection","GeomCollFromText","GeometryCollectionFromText","GeomCollFromWKB","GeometryCollectionFromWKB","GeometryCollection","GeometryN","GeometryType","GeomFromText","GeometryFromText","GeomFromWKB","GeometryFromWKB","GET_FORMAT","GET_LOCK","GLength","GREATEST","GROUP_CONCAT","GROUPING","GTID_SUBSET","GTID_SUBTRACT","HEX","HOUR","ICU_VERSION","IF","IFNULL","INET_ATON","INET_NTOA","INET6_ATON","INET6_NTOA","INSERT","INSTR","InteriorRingN","Intersects","INTERVAL","IS_FREE_LOCK","IS_IPV4","IS_IPV4_COMPAT","IS_IPV4_MAPPED","IS_IPV6","IS_USED_LOCK","IS_UUID","IsClosed","IsEmpty","ISNULL","IsSimple","JSON_APPEND","JSON_ARRAY","JSON_ARRAY_APPEND","JSON_ARRAY_INSERT","JSON_ARRAYAGG","JSON_CONTAINS","JSON_CONTAINS_PATH","JSON_DEPTH","JSON_EXTRACT","JSON_INSERT","JSON_KEYS","JSON_LENGTH","JSON_MERGE","JSON_MERGE_PATCH","JSON_MERGE_PRESERVE","JSON_OBJECT","JSON_OBJECTAGG","JSON_OVERLAPS","JSON_PRETTY","JSON_QUOTE","JSON_REMOVE","JSON_REPLACE","JSON_SCHEMA_VALID","JSON_SCHEMA_VALIDATION_REPORT","JSON_SEARCH","JSON_SET","JSON_STORAGE_FREE","JSON_STORAGE_SIZE","JSON_TABLE","JSON_TYPE","JSON_UNQUOTE","JSON_VALID","LAG","LAST_DAY","LAST_INSERT_ID","LAST_VALUE","LCASE","LEAD","LEAST","LEFT","LENGTH","LineFromText","LineStringFromText","LineFromWKB","LineStringFromWKB","LineString","LN","LOAD_FILE","LOCALTIME","LOCALTIMESTAMP","LOCATE","LOG","LOG10","LOG2","LOWER","LPAD","LTRIM","MAKE_SET","MAKEDATE","MAKETIME","MASK_INNER","MASK_OUTER","MASK_PAN","MASK_PAN_RELAXED","MASK_SSN","MASTER_POS_WAIT","MAX","MBRContains","MBRCoveredBy","MBRCovers","MBRDisjoint","MBREqual","MBREquals","MBRIntersects","MBROverlaps","MBRTouches","MBRWithin","MD5","MEMBER OF","MICROSECOND","MID","MIN","MINUTE","MLineFromText","MultiLineStringFromText","MLineFromWKB","MultiLineStringFromWKB","MOD","MONTH","MONTHNAME","MPointFromText","MultiPointFromText","MPointFromWKB","MultiPointFromWKB","MPolyFromText","MultiPolygonFromText","MPolyFromWKB","MultiPolygonFromWKB","MultiLineString","MultiPoint","MultiPolygon","NAME_CONST","NOT IN","NOW","NTH_VALUE","NTILE","NULLIF","NumGeometries","NumInteriorRings","NumPoints","OCT","OCTET_LENGTH","OLD_PASSWORD","ORD","Overlaps","PASSWORD","PERCENT_RANK","PERIOD_ADD","PERIOD_DIFF","PI","Point","PointFromText","PointFromWKB","PointN","PolyFromText","PolygonFromText","PolyFromWKB","PolygonFromWKB","Polygon","POSITION","POW","POWER","PS_CURRENT_THREAD_ID","PS_THREAD_ID","PROCEDURE ANALYSE","QUARTER","QUOTE","RADIANS","RAND","RANDOM_BYTES","RANK","REGEXP_INSTR","REGEXP_LIKE","REGEXP_REPLACE","REGEXP_REPLACE","RELEASE_ALL_LOCKS","RELEASE_LOCK","REPEAT","REPLACE","REVERSE","RIGHT","ROLES_GRAPHML","ROUND","ROW_COUNT","ROW_NUMBER","RPAD","RTRIM","SCHEMA","SEC_TO_TIME","SECOND","SESSION_USER","SHA1","SHA","SHA2","SIGN","SIN","SLEEP","SOUNDEX","SOURCE_POS_WAIT","SPACE","SQRT","SRID","ST_Area","ST_AsBinary","ST_AsWKB","ST_AsGeoJSON","ST_AsText","ST_AsWKT","ST_Buffer","ST_Buffer_Strategy","ST_Centroid","ST_Collect","ST_Contains","ST_ConvexHull","ST_Crosses","ST_Difference","ST_Dimension","ST_Disjoint","ST_Distance","ST_Distance_Sphere","ST_EndPoint","ST_Envelope","ST_Equals","ST_ExteriorRing","ST_FrechetDistance","ST_GeoHash","ST_GeomCollFromText","ST_GeometryCollectionFromText","ST_GeomCollFromTxt","ST_GeomCollFromWKB","ST_GeometryCollectionFromWKB","ST_GeometryN","ST_GeometryType","ST_GeomFromGeoJSON","ST_GeomFromText","ST_GeometryFromText","ST_GeomFromWKB","ST_GeometryFromWKB","ST_HausdorffDistance","ST_InteriorRingN","ST_Intersection","ST_Intersects","ST_IsClosed","ST_IsEmpty","ST_IsSimple","ST_IsValid","ST_LatFromGeoHash","ST_Length","ST_LineFromText","ST_LineStringFromText","ST_LineFromWKB","ST_LineStringFromWKB","ST_LineInterpolatePoint","ST_LineInterpolatePoints","ST_LongFromGeoHash","ST_Longitude","ST_MakeEnvelope","ST_MLineFromText","ST_MultiLineStringFromText","ST_MLineFromWKB","ST_MultiLineStringFromWKB","ST_MPointFromText","ST_MultiPointFromText","ST_MPointFromWKB","ST_MultiPointFromWKB","ST_MPolyFromText","ST_MultiPolygonFromText","ST_MPolyFromWKB","ST_MultiPolygonFromWKB","ST_NumGeometries","ST_NumInteriorRing","ST_NumInteriorRings","ST_NumPoints","ST_Overlaps","ST_PointAtDistance","ST_PointFromGeoHash","ST_PointFromText","ST_PointFromWKB","ST_PointN","ST_PolyFromText","ST_PolygonFromText","ST_PolyFromWKB","ST_PolygonFromWKB","ST_Simplify","ST_SRID","ST_StartPoint","ST_SwapXY","ST_SymDifference","ST_Touches","ST_Transform","ST_Union","ST_Validate","ST_Within","ST_X","ST_Y","StartPoint","STATEMENT_DIGEST","STATEMENT_DIGEST_TEXT","STD","STDDEV","STDDEV_POP","STDDEV_SAMP","STR_TO_DATE","STRCMP","SUBDATE","SUBSTR","SUBSTRING","SUBSTRING_INDEX","SUBTIME","SUM","SYSDATE","SYSTEM_USER","TAN","TIME","TIME_FORMAT","TIME_TO_SEC","TIMEDIFF","TIMESTAMP","TIMESTAMPADD","TIMESTAMPDIFF","TO_BASE64","TO_DAYS","TO_SECONDS","Touches","TRIM","TRUNCATE","UCASE","UNCOMPRESS","UNCOMPRESSED_LENGTH","UNHEX","UNIX_TIMESTAMP","UpdateXML","UPPER","USER","UTC_DATE","UTC_TIME","UTC_TIMESTAMP","UUID","UUID_SHORT","UUID_TO_BIN","VALIDATE_PASSWORD_STRENGTH","VALUES","VAR_POP","VAR_SAMP","VARIANCE","VERSION","WAIT_FOR_EXECUTED_GTID_SET","WAIT_UNTIL_SQL_THREAD_AFTER_GTIDS","WEEK","WEEKDAY","WEEKOFYEAR","WEIGHT_STRING","Within","X","Y","YEAR","YEARWEEK"],builtinVariables:[],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@]+/,{cases:{"@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@keywords":"keyword","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/#+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/'/,{token:"string",next:"@string"}],[/"/,{token:"string.double",next:"@stringDouble"}]],string:[[/\\'/,"string"],[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],stringDouble:[[/[^"]+/,"string.double"],[/""/,"string.double"],[/"/,{token:"string.double",next:"@pop"}]],complexIdentifiers:[[/`/,{token:"identifier.quote",next:"@quotedIdentifier"}]],quotedIdentifier:[[/[^`]+/,"identifier"],[/``/,"identifier"],[/`/,{token:"identifier.quote",next:"@pop"}]],scopes:[]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6214.a9a481a7.chunk.js b/ydb/core/viewer/monitoring/static/js/6214.a9a481a7.chunk.js deleted file mode 100644 index 25183bb0e7d8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6214.a9a481a7.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6214.a9a481a7.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6214],{26214:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>l,language:()=>m});var o,i,s=n(80781),r=Object.defineProperty,d=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,p=Object.prototype.hasOwnProperty,a=(e,t,n,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of c(t))p.call(e,i)||i===n||r(e,i,{get:()=>t[i],enumerable:!(o=d(t,i))||o.enumerable});return e},k={};a(k,o=s,"default"),i&&a(i,o,"default");var l={comments:{blockComment:["{/*","*/}"]},brackets:[["{","}"]],autoClosingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"\u201c",close:"\u201d"},{open:"\u2018",close:"\u2019"},{open:"`",close:"`"},{open:"{",close:"}"},{open:"(",close:")"},{open:"_",close:"_"},{open:"**",close:"**"},{open:"<",close:">"}],onEnterRules:[{beforeText:/^\s*- .+/,action:{indentAction:k.languages.IndentAction.None,appendText:"- "}},{beforeText:/^\s*\+ .+/,action:{indentAction:k.languages.IndentAction.None,appendText:"+ "}},{beforeText:/^\s*\* .+/,action:{indentAction:k.languages.IndentAction.None,appendText:"* "}},{beforeText:/^> /,action:{indentAction:k.languages.IndentAction.None,appendText:"> "}},{beforeText:/<\w+/,action:{indentAction:k.languages.IndentAction.Indent}},{beforeText:/\s+>\s*$/,action:{indentAction:k.languages.IndentAction.Indent}},{beforeText:/<\/\w+>/,action:{indentAction:k.languages.IndentAction.Outdent}},...Array.from({length:100},((e,t)=>({beforeText:new RegExp(`^${t}\\. .+`),action:{indentAction:k.languages.IndentAction.None,appendText:`${t+1}. `}})))]},m={defaultToken:"",tokenPostfix:".mdx",control:/[!#()*+.[\\\]_`{}\-]/,escapes:/\\@control/,tokenizer:{root:[[/^---$/,{token:"meta.content",next:"@frontmatter",nextEmbedded:"yaml"}],[/^\s*import/,{token:"keyword",next:"@import",nextEmbedded:"js"}],[/^\s*export/,{token:"keyword",next:"@export",nextEmbedded:"js"}],[/<\w+/,{token:"type.identifier",next:"@jsx"}],[/<\/?\w+>/,"type.identifier"],[/^(\s*)(>*\s*)(#{1,6}\s)/,[{token:"white"},{token:"comment"},{token:"keyword",next:"@header"}]],[/^(\s*)(>*\s*)([*+-])(\s+)/,["white","comment","keyword","white"]],[/^(\s*)(>*\s*)(\d{1,9}\.)(\s+)/,["white","comment","number","white"]],[/^(\s*)(>*\s*)(\d{1,9}\.)(\s+)/,["white","comment","number","white"]],[/^(\s*)(>*\s*)(-{3,}|\*{3,}|_{3,})$/,["white","comment","keyword"]],[/`{3,}(\s.*)?$/,{token:"string",next:"@codeblock_backtick"}],[/~{3,}(\s.*)?$/,{token:"string",next:"@codeblock_tilde"}],[/`{3,}(\S+).*$/,{token:"string",next:"@codeblock_highlight_backtick",nextEmbedded:"$1"}],[/~{3,}(\S+).*$/,{token:"string",next:"@codeblock_highlight_tilde",nextEmbedded:"$1"}],[/^(\s*)(-{4,})$/,["white","comment"]],[/^(\s*)(>+)/,["white","comment"]],{include:"content"}],content:[[/(\[)(.+)(]\()(.+)(\s+".*")(\))/,["","string.link","","type.identifier","string.link",""]],[/(\[)(.+)(]\()(.+)(\))/,["","type.identifier","","string.link",""]],[/(\[)(.+)(]\[)(.+)(])/,["","type.identifier","","type.identifier",""]],[/(\[)(.+)(]:\s+)(\S*)/,["","type.identifier","","string.link"]],[/(\[)(.+)(])/,["","type.identifier",""]],[/`.*`/,"variable.source"],[/_/,{token:"emphasis",next:"@emphasis_underscore"}],[/\*(?!\*)/,{token:"emphasis",next:"@emphasis_asterisk"}],[/\*\*/,{token:"strong",next:"@strong"}],[/{/,{token:"delimiter.bracket",next:"@expression",nextEmbedded:"js"}]],import:[[/'\s*(;|$)/,{token:"string",next:"@pop",nextEmbedded:"@pop"}]],expression:[[/{/,{token:"delimiter.bracket",next:"@expression"}],[/}/,{token:"delimiter.bracket",next:"@pop",nextEmbedded:"@pop"}]],export:[[/^\s*$/,{token:"delimiter.bracket",next:"@pop",nextEmbedded:"@pop"}]],jsx:[[/\s+/,""],[/(\w+)(=)("(?:[^"\\]|\\.)*")/,["attribute.name","operator","string"]],[/(\w+)(=)('(?:[^'\\]|\\.)*')/,["attribute.name","operator","string"]],[/(\w+(?=\s|>|={|$))/,["attribute.name"]],[/={/,{token:"delimiter.bracket",next:"@expression",nextEmbedded:"js"}],[/>/,{token:"type.identifier",next:"@pop"}]],header:[[/.$/,{token:"keyword",next:"@pop"}],{include:"content"},[/./,{token:"keyword"}]],strong:[[/\*\*/,{token:"strong",next:"@pop"}],{include:"content"},[/./,{token:"strong"}]],emphasis_underscore:[[/_/,{token:"emphasis",next:"@pop"}],{include:"content"},[/./,{token:"emphasis"}]],emphasis_asterisk:[[/\*(?!\*)/,{token:"emphasis",next:"@pop"}],{include:"content"},[/./,{token:"emphasis"}]],frontmatter:[[/^---$/,{token:"meta.content",nextEmbedded:"@pop",next:"@pop"}]],codeblock_highlight_backtick:[[/\s*`{3,}\s*$/,{token:"string",next:"@pop",nextEmbedded:"@pop"}],[/.*$/,"variable.source"]],codeblock_highlight_tilde:[[/\s*~{3,}\s*$/,{token:"string",next:"@pop",nextEmbedded:"@pop"}],[/.*$/,"variable.source"]],codeblock_backtick:[[/\s*`{3,}\s*$/,{token:"string",next:"@pop"}],[/.*$/,"variable.source"]],codeblock_tilde:[[/\s*~{3,}\s*$/,{token:"string",next:"@pop"}],[/.*$/,"variable.source"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/62308.fe05af2f.chunk.js b/ydb/core/viewer/monitoring/static/js/62308.fe05af2f.chunk.js new file mode 100644 index 000000000000..474119218418 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/62308.fe05af2f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[62308],{62308:(e,t,n)=>{n.r(t),n.d(t,{getCLS:()=>p,getFCP:()=>y,getFID:()=>k,getLCP:()=>F,getTTFB:()=>C});var i,a,r,o,u=function(e,t){return{name:e,value:void 0===t?-1:t,delta:0,entries:[],id:"v1-".concat(Date.now(),"-").concat(Math.floor(8999999999999*Math.random())+1e12)}},c=function(e,t){try{if(PerformanceObserver.supportedEntryTypes.includes(e)){if("first-input"===e&&!("PerformanceEventTiming"in self))return;var n=new PerformanceObserver((function(e){return e.getEntries().map(t)}));return n.observe({type:e,buffered:!0}),n}}catch(e){}},s=function(e,t){var n=function n(i){"pagehide"!==i.type&&"hidden"!==document.visibilityState||(e(i),t&&(removeEventListener("visibilitychange",n,!0),removeEventListener("pagehide",n,!0)))};addEventListener("visibilitychange",n,!0),addEventListener("pagehide",n,!0)},f=function(e){addEventListener("pageshow",(function(t){t.persisted&&e(t)}),!0)},d="function"==typeof WeakSet?new WeakSet:new Set,m=function(e,t,n){var i;return function(){t.value>=0&&(n||d.has(t)||"hidden"===document.visibilityState)&&(t.delta=t.value-(i||0),(t.delta||void 0===i)&&(i=t.value,e(t)))}},p=function(e,t){var n,i=u("CLS",0),a=function(e){e.hadRecentInput||(i.value+=e.value,i.entries.push(e),n())},r=c("layout-shift",a);r&&(n=m(e,i,t),s((function(){r.takeRecords().map(a),n()})),f((function(){i=u("CLS",0),n=m(e,i,t)})))},v=-1,l=function(){return"hidden"===document.visibilityState?0:1/0},h=function(){s((function(e){var t=e.timeStamp;v=t}),!0)},g=function(){return v<0&&(v=l(),h(),f((function(){setTimeout((function(){v=l(),h()}),0)}))),{get timeStamp(){return v}}},y=function(e,t){var n,i=g(),a=u("FCP"),r=function(e){"first-contentful-paint"===e.name&&(s&&s.disconnect(),e.startTime=0&&a1e12?new Date:performance.now())-e.timeStamp;"pointerdown"==e.type?function(e,t){var n=function(){b(e,t),a()},i=function(){a()},a=function(){removeEventListener("pointerup",n,S),removeEventListener("pointercancel",i,S)};addEventListener("pointerup",n,S),addEventListener("pointercancel",i,S)}(t,e):b(t,e)}},L=function(e){["mousedown","keydown","touchstart","pointerdown"].forEach((function(t){return e(t,w,S)}))},k=function(e,t){var n,r=g(),p=u("FID"),v=function(e){e.startTime{t.r(i),t.d(i,{conf:()=>n,language:()=>s});var n={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"<",close:">"}],folding:{markers:{start:new RegExp("^\\s*//\\s*(?:(?:#?region\\b)|(?:))")}}},s={defaultToken:"",tokenPostfix:".kt",keywords:["as","as?","break","class","continue","do","else","false","for","fun","if","in","!in","interface","is","!is","null","object","package","return","super","this","throw","true","try","typealias","val","var","when","while","by","catch","constructor","delegate","dynamic","field","file","finally","get","import","init","param","property","receiver","set","setparam","where","actual","abstract","annotation","companion","const","crossinline","data","enum","expect","external","final","infix","inline","inner","internal","lateinit","noinline","open","operator","out","override","private","protected","public","reified","sealed","suspend","tailrec","vararg","field","it"],operators:["+","-","*","/","%","=","+=","-=","*=","/=","%=","++","--","&&","||","!","==","!=","===","!==",">","<","<=",">=","[","]","!!","?.","?:","::","..",":","?","->","@",";","$","_"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/@\s*[a-zA-Z_\$][\w\$]*/,"annotation"],[/(@digits)[eE]([\-+]?(@digits))?[fFdD]?/,"number.float"],[/(@digits)\.(@digits)([eE][\-+]?(@digits))?[fFdD]?/,"number.float"],[/0[xX](@hexdigits)[Ll]?/,"number.hex"],[/0(@octaldigits)[Ll]?/,"number.octal"],[/0[bB](@binarydigits)[Ll]?/,"number.binary"],[/(@digits)[fFdD]/,"number.float"],[/(@digits)[lL]?/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"""/,"string","@multistring"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@javadoc"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],javadoc:[[/[^\/*]+/,"comment.doc"],[/\/\*/,"comment.doc","@push"],[/\/\*/,"comment.doc.invalid"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],multistring:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"""/,"string","@pop"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6447.2c0d9bda.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/62350.07b0039d.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6447.2c0d9bda.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/62350.07b0039d.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/62595.0c9bd5a0.chunk.js b/ydb/core/viewer/monitoring/static/js/62595.0c9bd5a0.chunk.js new file mode 100644 index 000000000000..12b311c7a5bb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/62595.0c9bd5a0.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[62595],{62595:(e,t,a)=>{a.d(t,{default:()=>r});var n=a(72956);const r=a.n(n)()},72956:e=>{function t(e){!function(e){e.languages.dataweave={url:/\b[A-Za-z]+:\/\/[\w/:.?=&-]+|\burn:[\w:.?=&-]+/,property:{pattern:/(?:\b\w+#)?(?:"(?:\\.|[^\\"\r\n])*"|\b\w+)(?=\s*[:@])/,greedy:!0},string:{pattern:/(["'`])(?:\\[\s\S]|(?!\1)[^\\])*\1/,greedy:!0},"mime-type":/\b(?:application|audio|image|multipart|text|video)\/[\w+-]+/,date:{pattern:/\|[\w:+-]+\|/,greedy:!0},comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?(?:\*\/|$)/,lookbehind:!0,greedy:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0,greedy:!0}],regex:{pattern:/\/(?:[^\\\/\r\n]|\\[^\r\n])+\//,greedy:!0},keyword:/\b(?:and|as|at|case|do|else|fun|if|input|is|match|not|ns|null|or|output|type|unless|update|using|var)\b/,function:/\b[A-Z_]\w*(?=\s*\()/i,number:/-?\b\d+(?:\.\d+)?(?:e[+-]?\d+)?\b/i,punctuation:/[{}[\];(),.:@]/,operator:/<<|>>|->|[<>~=]=?|!=|--?-?|\+\+?|!|\?/,boolean:/\b(?:false|true)\b/}}(e)}e.exports=t,t.displayName="dataweave",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6262.44dba84f.chunk.js b/ydb/core/viewer/monitoring/static/js/6262.44dba84f.chunk.js deleted file mode 100644 index 8563f87189ba..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6262.44dba84f.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6262.44dba84f.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6262],{66262:(e,n,i)=>{i.r(n),i.d(n,{conf:()=>t,language:()=>r});var t={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["begin","end"],["case","endcase"],["casex","endcase"],["casez","endcase"],["checker","endchecker"],["class","endclass"],["clocking","endclocking"],["config","endconfig"],["function","endfunction"],["generate","endgenerate"],["group","endgroup"],["interface","endinterface"],["module","endmodule"],["package","endpackage"],["primitive","endprimitive"],["program","endprogram"],["property","endproperty"],["specify","endspecify"],["sequence","endsequence"],["table","endtable"],["task","endtask"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{offSide:!1,markers:{start:new RegExp("^(?:\\s*|.*(?!\\/[\\/\\*])[^\\w])(?:begin|case(x|z)?|class|clocking|config|covergroup|function|generate|interface|module|package|primitive|property|program|sequence|specify|table|task)\\b"),end:new RegExp("^(?:\\s*|.*(?!\\/[\\/\\*])[^\\w])(?:end|endcase|endclass|endclocking|endconfig|endgroup|endfunction|endgenerate|endinterface|endmodule|endpackage|endprimitive|endproperty|endprogram|endsequence|endspecify|endtable|endtask)\\b")}}},r={defaultToken:"",tokenPostfix:".sv",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["accept_on","alias","always","always_comb","always_ff","always_latch","and","assert","assign","assume","automatic","before","begin","bind","bins","binsof","bit","break","buf","bufif0","bufif1","byte","case","casex","casez","cell","chandle","checker","class","clocking","cmos","config","const","constraint","context","continue","cover","covergroup","coverpoint","cross","deassign","default","defparam","design","disable","dist","do","edge","else","end","endcase","endchecker","endclass","endclocking","endconfig","endfunction","endgenerate","endgroup","endinterface","endmodule","endpackage","endprimitive","endprogram","endproperty","endspecify","endsequence","endtable","endtask","enum","event","eventually","expect","export","extends","extern","final","first_match","for","force","foreach","forever","fork","forkjoin","function","generate","genvar","global","highz0","highz1","if","iff","ifnone","ignore_bins","illegal_bins","implements","implies","import","incdir","include","initial","inout","input","inside","instance","int","integer","interconnect","interface","intersect","join","join_any","join_none","large","let","liblist","library","local","localparam","logic","longint","macromodule","matches","medium","modport","module","nand","negedge","nettype","new","nexttime","nmos","nor","noshowcancelled","not","notif0","notif1","null","or","output","package","packed","parameter","pmos","posedge","primitive","priority","program","property","protected","pull0","pull1","pulldown","pullup","pulsestyle_ondetect","pulsestyle_onevent","pure","rand","randc","randcase","randsequence","rcmos","real","realtime","ref","reg","reject_on","release","repeat","restrict","return","rnmos","rpmos","rtran","rtranif0","rtranif1","s_always","s_eventually","s_nexttime","s_until","s_until_with","scalared","sequence","shortint","shortreal","showcancelled","signed","small","soft","solve","specify","specparam","static","string","strong","strong0","strong1","struct","super","supply0","supply1","sync_accept_on","sync_reject_on","table","tagged","task","this","throughout","time","timeprecision","timeunit","tran","tranif0","tranif1","tri","tri0","tri1","triand","trior","trireg","type","typedef","union","unique","unique0","unsigned","until","until_with","untyped","use","uwire","var","vectored","virtual","void","wait","wait_order","wand","weak","weak0","weak1","while","wildcard","wire","with","within","wor","xnor","xor"],builtin_gates:["and","nand","nor","or","xor","xnor","buf","not","bufif0","bufif1","notif1","notif0","cmos","nmos","pmos","rcmos","rnmos","rpmos","tran","tranif1","tranif0","rtran","rtranif1","rtranif0"],operators:["=","+=","-=","*=","/=","%=","&=","|=","^=","<<=",">>+","<<<=",">>>=","?",":","+","-","!","~","&","~&","|","~|","^","~^","^~","+","-","*","/","%","==","!=","===","!==","==?","!=?","&&","||","**","<","<=",">",">=","&","|","^",">>","<<",">>>","<<<","++","--","->","<->","inside","dist","::","+:","-:","*>","&&&","|->","|=>","#=#"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],{include:"@numbers"},[/[;,.]/,"delimiter"],{include:"@strings"}],identifier_or_keyword:[[/@identifier/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}]],numbers:[[/\d+?[\d_]*(?:\.[\d_]+)?[eE][\-+]?\d+/,"number.float"],[/\d+?[\d_]*\.[\d_]+(?:\s*@timeunits)?/,"number.float"],[/(?:\d+?[\d_]*\s*)?'[sS]?[dD]\s*[0-9xXzZ?]+?[0-9xXzZ?_]*/,"number"],[/(?:\d+?[\d_]*\s*)?'[sS]?[bB]\s*[0-1xXzZ?]+?[0-1xXzZ?_]*/,"number.binary"],[/(?:\d+?[\d_]*\s*)?'[sS]?[oO]\s*[0-7xXzZ?]+?[0-7xXzZ?_]*/,"number.octal"],[/(?:\d+?[\d_]*\s*)?'[sS]?[hH]\s*[0-9a-fA-FxXzZ?]+?[0-9a-fA-FxXzZ?_]*/,"number.hex"],[/1step/,"number"],[/[\dxXzZ]+?[\dxXzZ_]*(?:\s*@timeunits)?/,"number"],[/'[01xXzZ]+/,"number"]],module_instance:[{include:"@whitespace"},[/(#?)(\()/,["",{token:"@brackets",next:"@port_connection"}]],[/@identifier\s*[;={}\[\],]/,{token:"@rematch",next:"@pop"}],[/@symbols|[;={}\[\],]/,{token:"@rematch",next:"@pop"}],[/@identifier/,"type"],[/;/,"delimiter","@pop"]],port_connection:[{include:"@identifier_or_keyword"},{include:"@whitespace"},[/@systemcall/,"variable.predefined"],{include:"@numbers"},{include:"@strings"},[/[,]/,"delimiter"],[/\(/,"@brackets","@port_connection"],[/\)/,"@brackets","@pop"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],strings:[[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],include:[[/(\s*)(")([\w*\/*]*)(.\w*)(")/,["","string.include.identifier","string.include.identifier","string.include.identifier",{token:"string.include.identifier",next:"@pop"}]],[/(\s*)(<)([\w*\/*]*)(.\w*)(>)/,["","string.include.identifier","string.include.identifier","string.include.identifier",{token:"string.include.identifier",next:"@pop"}]]],table:[{include:"@whitespace"},[/[()]/,"@brackets"],[/[:;]/,"delimiter"],[/[01\-*?xXbBrRfFpPnN]/,"variable.predefined"],["endtable","keyword.endtable","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/628.70d08de9.chunk.js b/ydb/core/viewer/monitoring/static/js/628.70d08de9.chunk.js deleted file mode 100644 index 73fe04813591..000000000000 --- a/ydb/core/viewer/monitoring/static/js/628.70d08de9.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[628],{90628:function(u,t,e){u.exports=function(u){"use strict";function t(u){return u&&"object"==typeof u&&"default"in u?u:{default:u}}var e=t(u);function n(u,t,e,n){var i={s:"muutama sekunti",m:"minuutti",mm:"%d minuuttia",h:"tunti",hh:"%d tuntia",d:"p\xe4iv\xe4",dd:"%d p\xe4iv\xe4\xe4",M:"kuukausi",MM:"%d kuukautta",y:"vuosi",yy:"%d vuotta",numbers:"nolla_yksi_kaksi_kolme_nelj\xe4_viisi_kuusi_seitsem\xe4n_kahdeksan_yhdeks\xe4n".split("_")},a={s:"muutaman sekunnin",m:"minuutin",mm:"%d minuutin",h:"tunnin",hh:"%d tunnin",d:"p\xe4iv\xe4n",dd:"%d p\xe4iv\xe4n",M:"kuukauden",MM:"%d kuukauden",y:"vuoden",yy:"%d vuoden",numbers:"nollan_yhden_kahden_kolmen_nelj\xe4n_viiden_kuuden_seitsem\xe4n_kahdeksan_yhdeks\xe4n".split("_")},_=n&&!t?a:i,s=_[e];return u<10?s.replace("%d",_.numbers[u]):s.replace("%d",u)}var i={name:"fi",weekdays:"sunnuntai_maanantai_tiistai_keskiviikko_torstai_perjantai_lauantai".split("_"),weekdaysShort:"su_ma_ti_ke_to_pe_la".split("_"),weekdaysMin:"su_ma_ti_ke_to_pe_la".split("_"),months:"tammikuu_helmikuu_maaliskuu_huhtikuu_toukokuu_kes\xe4kuu_hein\xe4kuu_elokuu_syyskuu_lokakuu_marraskuu_joulukuu".split("_"),monthsShort:"tammi_helmi_maalis_huhti_touko_kes\xe4_hein\xe4_elo_syys_loka_marras_joulu".split("_"),ordinal:function(u){return u+"."},weekStart:1,yearStart:4,relativeTime:{future:"%s p\xe4\xe4st\xe4",past:"%s sitten",s:n,m:n,mm:n,h:n,hh:n,d:n,dd:n,M:n,MM:n,y:n,yy:n},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD.MM.YYYY",LL:"D. MMMM[ta] YYYY",LLL:"D. MMMM[ta] YYYY, [klo] HH.mm",LLLL:"dddd, D. MMMM[ta] YYYY, [klo] HH.mm",l:"D.M.YYYY",ll:"D. MMM YYYY",lll:"D. MMM YYYY, [klo] HH.mm",llll:"ddd, D. MMM YYYY, [klo] HH.mm"}};return e.default.locale(i,null,!0),i}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/62888.922ae1c5.chunk.js b/ydb/core/viewer/monitoring/static/js/62888.922ae1c5.chunk.js new file mode 100644 index 000000000000..e2726822da52 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/62888.922ae1c5.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[62888],{2680:(e,t,n)=>{var a=n(43665),l=n(81061),r=n(28293),s=n(19305);e.exports=function(e,t){return function(n,i){var o=s(n)?a:l,c=t?t():{};return o(n,e,r(i,2),c)}}},18143:(e,t,n)=>{"use strict";n.d(t,{k:()=>u});var a=n(59284);const l=(0,n(69220).om)("progress");function r(e){const{text:t,offset:n=0}=e;return t?a.createElement("div",{className:l("text-inner"),style:{transform:`translateX(calc(var(--g-flow-direction) * ${-n}%))`}},t):null}function s({item:e}){const{value:t,color:n,className:r,theme:s,title:i,content:o,loading:c}=e,d={loading:c};return"undefined"===typeof n&&(d.theme=s||"default"),Number.isFinite(t)?a.createElement("div",{className:l("item",d,r),style:{width:`${t}%`,backgroundColor:n},title:i},o):null}function i(e){return e<100?e-100:0}function o(e){const{theme:t,colorStops:n,colorStopsValue:a,value:l}=e;if(n){const e=n.find(((e,t)=>{const r="number"===typeof a?a:l,s=t>1?n[t-1].stop:0,i=t=s&&r<=i}));return e?e.theme:t}return t}function c(e){const{stack:t,stackClassName:n,value:o,text:c}=e,d=i(o||function(e){return e.reduce(((e,{value:t})=>e+t),0)}(t));return a.createElement("div",{className:l("stack",n),style:{transform:`translateX(calc(var(--g-flow-direction) * ${d}%))`}},a.createElement("div",{className:l("item"),style:{width:-d+"%"}}),t.map(((e,t)=>a.createElement(s,{key:t,item:e}))),a.createElement(r,{offset:d,text:c}))}function d(e){const{value:t,loading:n,text:s}=e,c=i(t);return Number.isFinite(t)?a.createElement("div",{className:l("item",{theme:o(e),loading:n}),style:{transform:`translateX(calc(var(--g-flow-direction) * ${c}%))`}},a.createElement(r,{offset:c,text:s})):null}const u=a.forwardRef((function(e,t){const{text:n="",theme:r="default",size:s="m",loading:i=!1,className:o,qa:u}=e,m=Object.assign(Object.assign({},e),{text:n,theme:r,size:s,loading:i});return a.createElement("div",{ref:t,className:l({size:s},o),"data-qa":u},a.createElement("div",{className:l("text")},n),function(e){return void 0!==e.stack}(m)?a.createElement(c,Object.assign({},m)):a.createElement(d,Object.assign({},m)))}))},18677:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},36388:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 13.5a5.5 5.5 0 1 0 0-11 5.5 5.5 0 0 0 0 11M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14m1-4.5a1 1 0 1 1-2 0 1 1 0 0 1 2 0M8.75 5a.75.75 0 0 0-1.5 0v2.5a.75.75 0 0 0 1.5 0z",clipRule:"evenodd"}))},43665:e=>{e.exports=function(e,t,n,a){for(var l=-1,r=null==e?0:e.length;++l{"use strict";n.d(t,{o:()=>a});const a=(0,n(82435).withNaming)({e:"__",m:"_"})},63126:(e,t,n)=>{"use strict";n.d(t,{G:()=>c});var a=n(60712),l=n(59284),r=n(40569),s=n(53302);const i="--ydb-tree-view-level",o=(0,s.o)("ydb-tree-view");function c({children:e,name:t,title:n,icon:s,collapsed:c=!0,active:d=!1,onClick:u,onArrowClick:m,onActionsOpenToggle:v,hasArrow:h=!1,actions:f,additionalNodeElements:w,level:p}){const g=l.useCallback((e=>{if(!u)return;e.nativeEvent.composedPath().some((e=>e instanceof HTMLElement&&("BUTTON"===e.nodeName&&!e.hasAttribute("disabled")||e.hasAttribute("tabindex")&&e.tabIndex>-1)))||u()}),[u]),b=m||u;let x="tree-view_arrow",E="tree-view_children";return c&&(x+=" tree-view_arrow-collapsed",E+=" tree-view_children-collapsed"),(0,a.jsx)("div",{className:o(),style:{[i]:p},children:(0,a.jsxs)("div",{className:"tree-view",children:[(0,a.jsxs)("div",{className:`tree-view_item ${o("item",{active:d})}`,onClick:g,children:[(0,a.jsx)("button",{type:"button",className:`${x} ${o("arrow",{collapsed:c,hidden:!h})}`,disabled:!b,onClick:b}),(0,a.jsxs)("div",{className:o("content"),children:[s&&(0,a.jsx)("div",{className:o("icon"),children:s}),(0,a.jsx)("div",{className:o("text"),title:n,children:t}),f&&f.length>0&&(0,a.jsxs)("div",{className:o("actions"),children:[w,(0,a.jsx)(r.r,{onOpenToggle:v,defaultSwitcherProps:{view:"flat-secondary",size:"s",pin:"brick-brick"},items:f})]})]})]}),(0,a.jsx)("div",{className:`${E} ${o("container",{collapsed:c})}`,children:c?null:e})]})})}},64470:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M9 2H7a.5.5 0 0 0-.5.5V3h3v-.5A.5.5 0 0 0 9 2m2 1v-.5a2 2 0 0 0-2-2H7a2 2 0 0 0-2 2V3H2.251a.75.75 0 0 0 0 1.5h.312l.317 7.625A3 3 0 0 0 5.878 15h4.245a3 3 0 0 0 2.997-2.875l.318-7.625h.312a.75.75 0 0 0 0-1.5zm.936 1.5H4.064l.315 7.562A1.5 1.5 0 0 0 5.878 13.5h4.245a1.5 1.5 0 0 0 1.498-1.438zm-6.186 2v5a.75.75 0 0 0 1.5 0v-5a.75.75 0 0 0-1.5 0m3.75-.75a.75.75 0 0 1 .75.75v5a.75.75 0 0 1-1.5 0v-5a.75.75 0 0 1 .75-.75",clipRule:"evenodd"}))},65872:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M11.423 1A3.577 3.577 0 0 1 15 4.577c0 .27-.108.53-.3.722l-.528.529-1.971 1.971-5.059 5.059a3 3 0 0 1-1.533.82l-2.638.528a1 1 0 0 1-1.177-1.177l.528-2.638a3 3 0 0 1 .82-1.533l5.059-5.059 2.5-2.5c.191-.191.451-.299.722-.299m-2.31 4.009-4.91 4.91a1.5 1.5 0 0 0-.41.766l-.38 1.903 1.902-.38a1.5 1.5 0 0 0 .767-.41l4.91-4.91a2.08 2.08 0 0 0-1.88-1.88m3.098.658a3.6 3.6 0 0 0-1.878-1.879l1.28-1.28c.995.09 1.788.884 1.878 1.88z",clipRule:"evenodd"}))},74321:(e,t,n)=>{"use strict";n.d(t,{S:()=>c});var a=n(59284),l=n(64222),r=n(46898);function s(e){return a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),a.createElement("path",{d:"M4 7h9v3H4z"}))}function i(e){return a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),a.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const o=(0,n(69220).om)("checkbox"),c=a.forwardRef((function(e,t){const{size:n="m",indeterminate:c,disabled:d=!1,content:u,children:m,title:v,style:h,className:f,qa:w}=e,{checked:p,inputProps:g}=(0,l.v)(e),b=u||m,x=a.createElement("span",{className:o("indicator")},a.createElement("span",{className:o("icon"),"aria-hidden":!0},c?a.createElement(s,{className:o("icon-svg",{type:"dash"})}):a.createElement(i,{className:o("icon-svg",{type:"tick"})})),a.createElement("input",Object.assign({},g,{className:o("control")})),a.createElement("span",{className:o("outline")}));return a.createElement(r.m,{ref:t,title:v,style:h,size:n,disabled:d,className:o({size:n,disabled:d,indeterminate:c,checked:p},f),qa:w,control:x},b)}))},76938:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 1 1-6.445 7.348.75.75 0 1 1 1.487-.194A5.001 5.001 0 1 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 0 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5",clipRule:"evenodd"}))},78018:(e,t,n)=>{var a=n(80472),l=n(2680),r=Object.prototype.hasOwnProperty,s=l((function(e,t,n){r.call(e,n)?e[n].push(t):a(e,n,[t])}));e.exports=s},79522:(e,t,n)=>{"use strict";n.d(t,{E:()=>N});var a=n(59284),l=n(41668),r=n(90826);const s=a.createContext(void 0),i=a.createContext(void 0);function o(e){const{size:t,disabled:n,defaultExpanded:l,arrowPosition:o,summary:c,keepMounted:d,onUpdate:u,expanded:m}=e,[v,h]=a.useState((()=>Boolean(l))),f=void 0!==m,w=(0,r.u)(),p=`disclosure${w}`;return a.createElement(s.Provider,{value:{size:t,disabled:n,summary:c,arrowPosition:o,keepMounted:d,expanded:f?m:v,ariaControls:w,ariaLabelledby:p}},a.createElement(i.Provider,{value:()=>{h((e=>!e));u(f?!m:!v)}},e.children))}function c(){const e=a.useContext(s);if(void 0===e)throw new Error("useDisclosureAttributes must be used within DisclosureProvider");return e}var d=n(72630),u=n(6826);const m=(0,n(69220).om)("disclosure"),v="disclosure-summary",h="disclosure-details";function f({children:e}){const t=a.useRef(null),{ariaControls:n,ariaLabelledby:l,keepMounted:r,expanded:s}=c();return a.createElement(d.A,{nodeRef:t,in:s,addEndListener:e=>{var n;return null===(n=t.current)||void 0===n?void 0:n.addEventListener("animationend",e)},classNames:(0,u.L)(m),mountOnEnter:!r,unmountOnExit:!r,appear:!0},a.createElement("div",{ref:t,id:n,role:"region","aria-labelledby":l,className:m("content",{visible:s}),"data-qa":h},e))}f.displayName="DisclosureDetails";var w=n(33705),p=n(27629);const g={m:14,l:16,xl:20};function b(){(0,p.m)('[Disclosure] Physical values (left, right) of "arrowPosition" property are deprecated. Use logical values (start, end) instead.')}function x({children:e}){const t=function(){const e=a.useContext(i);if(void 0===e)throw new Error("useToggleDisclosure must be used within DisclosureProvider");return e}(),{ariaControls:n,ariaLabelledby:l,expanded:r,disabled:s}=c(),o={onClick:t,ariaControls:n,id:l,expanded:r,disabled:s};return e(o,a.createElement(E,Object.assign({},o)))}function E({onClick:e,ariaControls:t,id:n,expanded:l,disabled:r}){const{size:s,summary:i,arrowPosition:o}=c();let d=o;return"left"===d&&(b(),d="start"),"right"===d&&(b(),d="end"),a.createElement("button",{type:"button","aria-expanded":l,className:m("trigger",{disabled:r,arrow:d}),"aria-controls":t,id:n,onClick:e,disabled:r,"data-qa":v},a.createElement(w.I,{size:g[s],direction:l?"top":"bottom"}),i)}x.displayName="DisclosureSummary";const y=(0,l.g)(x),N=a.forwardRef((function(e,t){const{size:n="m",disabled:l=!1,defaultExpanded:r=!1,arrowPosition:s="start",summary:i="",className:c,keepMounted:d=!0,children:u,onUpdate:v=()=>{},expanded:h,qa:w}=e,[p,g]=function(e){const t=a.Children.toArray(e);let n,l;const r=[];for(const a of t){if(y(a)){if(n)throw new Error("Only one component is allowed");n=a}else r.push(a)}r.length>0&&(l=a.createElement(f,null,r));n||(n=a.createElement(x,null,(e=>a.createElement(E,Object.assign({},e)))));return[n,l]}(u);return a.createElement(o,{disabled:l,defaultExpanded:r,expanded:h,keepMounted:d,size:n,summary:i,arrowPosition:s,onUpdate:v},a.createElement("section",{ref:t,className:m({size:n},c),"data-qa":w},p,g))}));N.Summary=x,N.displayName="Disclosure"},79879:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"m3.003 4.702 4.22-2.025a1.8 1.8 0 0 1 1.554 0l4.22 2.025a.89.89 0 0 1 .503.8V6a8.55 8.55 0 0 1-3.941 7.201l-.986.631a1.06 1.06 0 0 1-1.146 0l-.986-.63A8.55 8.55 0 0 1 2.5 6v-.498c0-.341.196-.652.503-.8m3.57-3.377L2.354 3.35A2.39 2.39 0 0 0 1 5.502V6a10.05 10.05 0 0 0 4.632 8.465l.986.63a2.56 2.56 0 0 0 2.764 0l.986-.63A10.05 10.05 0 0 0 15 6v-.498c0-.918-.526-1.755-1.354-2.152l-4.22-2.025a3.3 3.3 0 0 0-2.852 0M9.5 7a1.5 1.5 0 0 1-.75 1.3v1.95a.75.75 0 0 1-1.5 0V8.3A1.5 1.5 0 1 1 9.5 7",clipRule:"evenodd"}))},81061:(e,t,n)=>{var a=n(75125);e.exports=function(e,t,n,l){return a(e,(function(e,a,r){t(l,e,n(e),r)})),l}},93381:(e,t,n)=>{"use strict";n.d(t,{A:()=>l});var a=n(59284);const l=e=>a.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),a.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.5 8a5.5 5.5 0 1 1-11 0 5.5 5.5 0 0 1 11 0M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0M8.75 5.5a.75.75 0 0 0-1.5 0v1.75H5.5a.75.75 0 1 0 0 1.5h1.75v1.75a.75.75 0 0 0 1.5 0V8.75h1.75a.75.75 0 0 0 0-1.5H8.75z",clipRule:"evenodd"}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/63008.97387142.chunk.js b/ydb/core/viewer/monitoring/static/js/63008.97387142.chunk.js new file mode 100644 index 000000000000..f88ea184a779 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/63008.97387142.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[63008],{63008:function(_,e,Y){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var Y=e(_),d={name:"ja",weekdays:"\u65e5\u66dc\u65e5_\u6708\u66dc\u65e5_\u706b\u66dc\u65e5_\u6c34\u66dc\u65e5_\u6728\u66dc\u65e5_\u91d1\u66dc\u65e5_\u571f\u66dc\u65e5".split("_"),weekdaysShort:"\u65e5_\u6708_\u706b_\u6c34_\u6728_\u91d1_\u571f".split("_"),weekdaysMin:"\u65e5_\u6708_\u706b_\u6c34_\u6728_\u91d1_\u571f".split("_"),months:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),ordinal:function(_){return _+"\u65e5"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5 HH:mm",LLLL:"YYYY\u5e74M\u6708D\u65e5 dddd HH:mm",l:"YYYY/MM/DD",ll:"YYYY\u5e74M\u6708D\u65e5",lll:"YYYY\u5e74M\u6708D\u65e5 HH:mm",llll:"YYYY\u5e74M\u6708D\u65e5(ddd) HH:mm"},meridiem:function(_){return _<12?"\u5348\u524d":"\u5348\u5f8c"},relativeTime:{future:"%s\u5f8c",past:"%s\u524d",s:"\u6570\u79d2",m:"1\u5206",mm:"%d\u5206",h:"1\u6642\u9593",hh:"%d\u6642\u9593",d:"1\u65e5",dd:"%d\u65e5",M:"1\u30f6\u6708",MM:"%d\u30f6\u6708",y:"1\u5e74",yy:"%d\u5e74"}};return Y.default.locale(d,null,!0),d}(Y(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6324.de01edfb.chunk.js b/ydb/core/viewer/monitoring/static/js/6324.de01edfb.chunk.js deleted file mode 100644 index bce156ec6f05..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6324.de01edfb.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6324],{26324:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),t={name:"id",weekdays:"Minggu_Senin_Selasa_Rabu_Kamis_Jumat_Sabtu".split("_"),months:"Januari_Februari_Maret_April_Mei_Juni_Juli_Agustus_September_Oktober_November_Desember".split("_"),weekdaysShort:"Min_Sen_Sel_Rab_Kam_Jum_Sab".split("_"),monthsShort:"Jan_Feb_Mar_Apr_Mei_Jun_Jul_Agt_Sep_Okt_Nov_Des".split("_"),weekdaysMin:"Mg_Sn_Sl_Rb_Km_Jm_Sb".split("_"),weekStart:1,formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [pukul] HH.mm",LLLL:"dddd, D MMMM YYYY [pukul] HH.mm"},relativeTime:{future:"dalam %s",past:"%s yang lalu",s:"beberapa detik",m:"semenit",mm:"%d menit",h:"sejam",hh:"%d jam",d:"sehari",dd:"%d hari",M:"sebulan",MM:"%d bulan",y:"setahun",yy:"%d tahun"},ordinal:function(e){return e+"."}};return a.default.locale(t,null,!0),t}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6342.a2819c87.chunk.js b/ydb/core/viewer/monitoring/static/js/6342.a2819c87.chunk.js deleted file mode 100644 index 9fc8d136d662..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6342.a2819c87.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6342.a2819c87.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6342],{86342:(e,t,p)=>{p.r(t),p.d(t,{conf:()=>n,language:()=>i});var n={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string"]},{open:"[",close:"]",notIn:["string"]},{open:"(",close:")",notIn:["string"]},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]}],folding:{markers:{start:new RegExp("^\\s*(#|//)region\\b"),end:new RegExp("^\\s*(#|//)endregion\\b")}}},i={defaultToken:"",tokenPostfix:"",tokenizer:{root:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.root"}],[/)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)(script)/,["delimiter.html",{token:"tag.html",next:"@script"}]],[/(<)(style)/,["delimiter.html",{token:"tag.html",next:"@style"}]],[/(<)([:\w]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)(\w+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/]+/,"metatag.content.html"],[/>/,"metatag.html","@pop"]],comment:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.comment"}],[/-->/,"comment.html","@pop"],[/[^-]+/,"comment.content.html"],[/./,"comment.content.html"]],otherTag:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.otherTag"}],[/\/?>/,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.script"}],[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],scriptAfterType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.scriptAfterType"}],[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.scriptAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.scriptWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInEmbeddedState.scriptEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],style:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.style"}],[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],styleAfterType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.styleAfterType"}],[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.styleAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.styleWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInEmbeddedState.styleEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],phpInSimpleState:[[/<\?((php)|=)?/,"metatag.php"],[/\?>/,{token:"metatag.php",switchTo:"@$S2.$S3"}],{include:"phpRoot"}],phpInEmbeddedState:[[/<\?((php)|=)?/,"metatag.php"],[/\?>/,{token:"metatag.php",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}],{include:"phpRoot"}],phpRoot:[[/[a-zA-Z_]\w*/,{cases:{"@phpKeywords":{token:"keyword.php"},"@phpCompileTimeConstants":{token:"constant.php"},"@default":"identifier.php"}}],[/[$a-zA-Z_]\w*/,{cases:{"@phpPreDefinedVariables":{token:"variable.predefined.php"},"@default":"variable.php"}}],[/[{}]/,"delimiter.bracket.php"],[/[\[\]]/,"delimiter.array.php"],[/[()]/,"delimiter.parenthesis.php"],[/[ \t\r\n]+/],[/(#|\/\/)$/,"comment.php"],[/(#|\/\/)/,"comment.php","@phpLineComment"],[/\/\*/,"comment.php","@phpComment"],[/"/,"string.php","@phpDoubleQuoteString"],[/'/,"string.php","@phpSingleQuoteString"],[/[\+\-\*\%\&\|\^\~\!\=\<\>\/\?\;\:\.\,\@]/,"delimiter.php"],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float.php"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float.php"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F]/,"number.hex.php"],[/0[0-7']*[0-7]/,"number.octal.php"],[/0[bB][0-1']*[0-1]/,"number.binary.php"],[/\d[\d']*/,"number.php"],[/\d/,"number.php"]],phpComment:[[/\*\//,"comment.php","@pop"],[/[^*]+/,"comment.php"],[/./,"comment.php"]],phpLineComment:[[/\?>/,{token:"@rematch",next:"@pop"}],[/.$/,"comment.php","@pop"],[/[^?]+$/,"comment.php","@pop"],[/[^?]+/,"comment.php"],[/./,"comment.php"]],phpDoubleQuoteString:[[/[^\\"]+/,"string.php"],[/@escapes/,"string.escape.php"],[/\\./,"string.escape.invalid.php"],[/"/,"string.php","@pop"]],phpSingleQuoteString:[[/[^\\']+/,"string.php"],[/@escapes/,"string.escape.php"],[/\\./,"string.escape.invalid.php"],[/'/,"string.php","@pop"]]},phpKeywords:["abstract","and","array","as","break","callable","case","catch","cfunction","class","clone","const","continue","declare","default","do","else","elseif","enddeclare","endfor","endforeach","endif","endswitch","endwhile","extends","false","final","for","foreach","function","global","goto","if","implements","interface","instanceof","insteadof","namespace","new","null","object","old_function","or","private","protected","public","resource","static","switch","throw","trait","try","true","use","var","while","xor","die","echo","empty","exit","eval","include","include_once","isset","list","require","require_once","return","print","unset","yield","__construct"],phpCompileTimeConstants:["__CLASS__","__DIR__","__FILE__","__LINE__","__NAMESPACE__","__METHOD__","__FUNCTION__","__TRAIT__"],phpPreDefinedVariables:["$GLOBALS","$_SERVER","$_GET","$_POST","$_FILES","$_REQUEST","$_SESSION","$_ENV","$_COOKIE","$php_errormsg","$HTTP_RAW_POST_DATA","$http_response_header","$argc","$argv"],escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6358.2997762b.chunk.js b/ydb/core/viewer/monitoring/static/js/6358.2997762b.chunk.js deleted file mode 100644 index ad04c091b1da..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6358.2997762b.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6358],{26358:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),n={name:"mr",weekdays:"\u0930\u0935\u093f\u0935\u093e\u0930_\u0938\u094b\u092e\u0935\u093e\u0930_\u092e\u0902\u0917\u0933\u0935\u093e\u0930_\u092c\u0941\u0927\u0935\u093e\u0930_\u0917\u0941\u0930\u0942\u0935\u093e\u0930_\u0936\u0941\u0915\u094d\u0930\u0935\u093e\u0930_\u0936\u0928\u093f\u0935\u093e\u0930".split("_"),months:"\u091c\u093e\u0928\u0947\u0935\u093e\u0930\u0940_\u092b\u0947\u092c\u094d\u0930\u0941\u0935\u093e\u0930\u0940_\u092e\u093e\u0930\u094d\u091a_\u090f\u092a\u094d\u0930\u093f\u0932_\u092e\u0947_\u091c\u0942\u0928_\u091c\u0941\u0932\u0948_\u0911\u0917\u0938\u094d\u091f_\u0938\u092a\u094d\u091f\u0947\u0902\u092c\u0930_\u0911\u0915\u094d\u091f\u094b\u092c\u0930_\u0928\u094b\u0935\u094d\u0939\u0947\u0902\u092c\u0930_\u0921\u093f\u0938\u0947\u0902\u092c\u0930".split("_"),weekdaysShort:"\u0930\u0935\u093f_\u0938\u094b\u092e_\u092e\u0902\u0917\u0933_\u092c\u0941\u0927_\u0917\u0941\u0930\u0942_\u0936\u0941\u0915\u094d\u0930_\u0936\u0928\u093f".split("_"),monthsShort:"\u091c\u093e\u0928\u0947._\u092b\u0947\u092c\u094d\u0930\u0941._\u092e\u093e\u0930\u094d\u091a._\u090f\u092a\u094d\u0930\u093f._\u092e\u0947._\u091c\u0942\u0928._\u091c\u0941\u0932\u0948._\u0911\u0917._\u0938\u092a\u094d\u091f\u0947\u0902._\u0911\u0915\u094d\u091f\u094b._\u0928\u094b\u0935\u094d\u0939\u0947\u0902._\u0921\u093f\u0938\u0947\u0902.".split("_"),weekdaysMin:"\u0930_\u0938\u094b_\u092e\u0902_\u092c\u0941_\u0917\u0941_\u0936\u0941_\u0936".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm \u0935\u093e\u091c\u0924\u093e",LTS:"A h:mm:ss \u0935\u093e\u091c\u0924\u093e",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm \u0935\u093e\u091c\u0924\u093e",LLLL:"dddd, D MMMM YYYY, A h:mm \u0935\u093e\u091c\u0924\u093e"}};return t.default.locale(n,null,!0),n}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/63653.c2f7dcde.chunk.js b/ydb/core/viewer/monitoring/static/js/63653.c2f7dcde.chunk.js new file mode 100644 index 000000000000..7418e5783f7a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/63653.c2f7dcde.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[63653],{63653:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"zh-hk",months:"\u4e00\u6708_\u4e8c\u6708_\u4e09\u6708_\u56db\u6708_\u4e94\u6708_\u516d\u6708_\u4e03\u6708_\u516b\u6708_\u4e5d\u6708_\u5341\u6708_\u5341\u4e00\u6708_\u5341\u4e8c\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),weekdays:"\u661f\u671f\u65e5_\u661f\u671f\u4e00_\u661f\u671f\u4e8c_\u661f\u671f\u4e09_\u661f\u671f\u56db_\u661f\u671f\u4e94_\u661f\u671f\u516d".split("_"),weekdaysShort:"\u9031\u65e5_\u9031\u4e00_\u9031\u4e8c_\u9031\u4e09_\u9031\u56db_\u9031\u4e94_\u9031\u516d".split("_"),weekdaysMin:"\u65e5_\u4e00_\u4e8c_\u4e09_\u56db_\u4e94_\u516d".split("_"),ordinal:function(_,e){return"W"===e?_+"\u9031":_+"\u65e5"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5 HH:mm",LLLL:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm"},relativeTime:{future:"%s\u5167",past:"%s\u524d",s:"\u5e7e\u79d2",m:"\u4e00\u5206\u9418",mm:"%d \u5206\u9418",h:"\u4e00\u5c0f\u6642",hh:"%d \u5c0f\u6642",d:"\u4e00\u5929",dd:"%d \u5929",M:"\u4e00\u500b\u6708",MM:"%d \u500b\u6708",y:"\u4e00\u5e74",yy:"%d \u5e74"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/63679.05a63e19.chunk.js b/ydb/core/viewer/monitoring/static/js/63679.05a63e19.chunk.js new file mode 100644 index 000000000000..f3d9ebfc1a6c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/63679.05a63e19.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[63679],{86060:function(e,_,t){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=_(e),r={name:"lb",weekdays:"Sonndeg_M\xe9indeg_D\xebnschdeg_M\xebttwoch_Donneschdeg_Freideg_Samschdeg".split("_"),months:"Januar_Februar_M\xe4erz_Abr\xebll_Mee_Juni_Juli_August_September_Oktober_November_Dezember".split("_"),weekStart:1,weekdaysShort:"So._M\xe9._D\xeb._M\xeb._Do._Fr._Sa.".split("_"),monthsShort:"Jan._Febr._Mrz._Abr._Mee_Jun._Jul._Aug._Sept._Okt._Nov._Dez.".split("_"),weekdaysMin:"So_M\xe9_D\xeb_M\xeb_Do_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"H:mm [Auer]",LTS:"H:mm:ss [Auer]",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm [Auer]",LLLL:"dddd, D. MMMM YYYY H:mm [Auer]"}};return t.default.locale(r,null,!0),r}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6374.be0c5879.chunk.js b/ydb/core/viewer/monitoring/static/js/6374.be0c5879.chunk.js deleted file mode 100644 index 32d8ca765c75..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6374.be0c5879.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6374.be0c5879.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6374],{36374:(e,o,t)=>{t.r(o),t.d(o,{conf:()=>n,language:()=>s});var n={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"},{open:'"',close:'"'},{open:"(*",close:"*)"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"},{open:'"',close:'"'},{open:"(*",close:"*)"}]},s={defaultToken:"",tokenPostfix:".cameligo",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["abs","assert","block","Bytes","case","Crypto","Current","else","failwith","false","for","fun","if","in","let","let%entry","let%init","List","list","Map","map","match","match%nat","mod","not","operation","Operation","of","record","Set","set","sender","skip","source","String","then","to","true","type","with"],typeKeywords:["int","unit","string","tz","nat","bool"],operators:["=",">","<","<=",">=","<>",":",":=","and","mod","or","+","-","*","/","@","&","^","%","->","<-","&&","||"],symbols:/[=><:@\^&|+\-*\/\^%]+/,tokenizer:{root:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\$[0-9a-fA-F]{1,16}/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'/,"string","@string"],[/'[^\\']'/,"string"],[/'/,"string.invalid"],[/\#\d+/,"string"]],comment:[[/[^\(\*]+/,"comment"],[/\*\)/,"comment","@pop"],[/\(\*/,"comment"]],string:[[/[^\\']+/,"string"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"],[/\(\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/63769.731ffb68.chunk.js b/ydb/core/viewer/monitoring/static/js/63769.731ffb68.chunk.js new file mode 100644 index 000000000000..25e6ab08a238 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/63769.731ffb68.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[63769],{63769:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-sg",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/63782.48301ab7.chunk.js b/ydb/core/viewer/monitoring/static/js/63782.48301ab7.chunk.js new file mode 100644 index 000000000000..d4cb859cfb97 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/63782.48301ab7.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[63782],{11731:e=>{function n(e){!function(e){var n=e.languages.parser=e.languages.extend("markup",{keyword:{pattern:/(^|[^^])(?:\^(?:case|eval|for|if|switch|throw)\b|@(?:BASE|CLASS|GET(?:_DEFAULT)?|OPTIONS|SET_DEFAULT|USE)\b)/,lookbehind:!0},variable:{pattern:/(^|[^^])\B\$(?:\w+|(?=[.{]))(?:(?:\.|::?)\w+)*(?:\.|::?)?/,lookbehind:!0,inside:{punctuation:/\.|:+/}},function:{pattern:/(^|[^^])\B[@^]\w+(?:(?:\.|::?)\w+)*(?:\.|::?)?/,lookbehind:!0,inside:{keyword:{pattern:/(^@)(?:GET_|SET_)/,lookbehind:!0},punctuation:/\.|:+/}},escape:{pattern:/\^(?:[$^;@()\[\]{}"':]|#[a-f\d]*)/i,alias:"builtin"},punctuation:/[\[\](){};]/});n=e.languages.insertBefore("parser","keyword",{"parser-comment":{pattern:/(\s)#.*/,lookbehind:!0,alias:"comment"},expression:{pattern:/(^|[^^])\((?:[^()]|\((?:[^()]|\((?:[^()])*\))*\))*\)/,greedy:!0,lookbehind:!0,inside:{string:{pattern:/(^|[^^])(["'])(?:(?!\2)[^^]|\^[\s\S])*\2/,lookbehind:!0},keyword:n.keyword,variable:n.variable,function:n.function,boolean:/\b(?:false|true)\b/,number:/\b(?:0x[a-f\d]+|\d+(?:\.\d*)?(?:e[+-]?\d+)?)\b/i,escape:n.escape,operator:/[~+*\/\\%]|!(?:\|\|?|=)?|&&?|\|\|?|==|<[<=]?|>[>=]?|-[fd]?|\b(?:def|eq|ge|gt|in|is|le|lt|ne)\b/,punctuation:n.punctuation}}}),e.languages.insertBefore("inside","punctuation",{expression:n.expression,keyword:n.keyword,variable:n.variable,function:n.function,escape:n.escape,"parser-punctuation":{pattern:n.punctuation,alias:"punctuation"}},n.tag.inside["attr-value"])}(e)}e.exports=n,n.displayName="parser",n.aliases=[]},63782:(e,n,a)=>{a.d(n,{default:()=>i});var t=a(11731);const i=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6397.b8cf6fae.chunk.js b/ydb/core/viewer/monitoring/static/js/6397.b8cf6fae.chunk.js deleted file mode 100644 index 8b25c8ad5a36..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6397.b8cf6fae.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6397],{66397:(t,e,a)=>{a.r(e),a.d(e,{completionLists:()=>m,conf:()=>I,language:()=>g});const r=["AND","ANY","AS","ASC","ATTACH","BETWEEN","CASE","CAST","CREATE","CROSS","DATABASE","DATABASES","DEFAULT","DELETE","DESC","DESCRIBE","DETACH","DISTINCT","DROP","ELSE","END","FOREIGN","FROM","GRANT","HAVING","IF","INNER","INSERT","JOIN","KEY","LEFT","NATURAL","NOT","OFFSET","ON","OPTIMIZE","OR","OUTER","PREWHERE","PRIMARY","PROCESSLIST","REFERENCES","RIGHT","SELECT","SHOW","TABLE","THEN","TO","TOTALS","TYPE","UNION","UPDATE","USE","WHEN","WHERE","WITH"],n=["true","false","NULL"],i=["__bitBoolMaskAnd","__bitBoolMaskOr","__bitSwapLastTwo","__bitWrapperFunc","__getScalar","accurate_Cast","accurate_CastOrNull","accurateCast","accurateCastOrNull","acosh","addDays","addHours","addMinutes","addMonths","addQuarters","addressToLine","addressToSymbol","addSeconds","addWeeks","addYears","aes_decrypt_mysql","aes_encrypt_mysql","aggThrow","alphaTokens","and","any","anyHeavy","anyLast","appendTrailingCharIfAbsent","argMax","argMin","array","arrayAll","arrayAUC","arrayAvg","arrayCompact","arrayConcat","arrayCount","arrayCumSum","arrayCumSumNonNegative","arrayDifference","arrayDistinct","arrayElement","arrayEnumerate","arrayEnumerateDense","arrayEnumerateDenseRanked","arrayEnumerateUniq","arrayEnumerateUniqRanked","arrayExists","arrayFill","arrayFilter","arrayFirst","arrayFirstIndex","arrayFlatten","arrayIntersect","arrayJoin","arrayMap","arrayMax","arrayMin","arrayPopBack","arrayPopFront","arrayProduct","arrayPushBack","arrayPushFront","arrayReduce","arrayReduceInRanges","arrayResize","arrayReverse","arrayReverseFill","arrayReverseSort","arrayReverseSplit","arraySlice","arraySort","arraySplit","arrayStringConcat","arraySum","arrayUniq","arrayWithConstant","arrayZip","asinh","assumeNotNull","atanh","avgWeighted","bar","base64Decode","base64Encode","basename","bitAnd","bitCount","bitHammingDistance","bitmaskToArray","bitmaskToList","bitNot","bitOr","bitPositionsToArray","bitRotateLeft","bitRotateRight","bitShiftLeft","bitShiftRight","bitTest","bitTestAll","bitTestAny","bitXor","blockNumber","blockSerializedSize","blockSize","boundingRatio","buildId","byteSize","caseWithExpr","caseWithExpression","caseWithoutExpr","caseWithoutExpression","categoricalInformationValue","cbrt","cityHash64","concatAssumeInjective","ConvertYson","corrStable","cosh","countDigits","countEqual","countMatches","countMatchesCaseInsensitive","countSubstringsCaseInsensitive","countSubstringsCaseInsensitiveUTF8","covarPop","covarPopStable","covarSamp","covarSampStable","currentDatabase","currentProfiles","currentRoles","currentUser","cutFragment","cutIPv6","cutQueryString","cutQueryStringAndFragment","cutToFirstSignificantSubdomain","cutToFirstSignificantSubdomainCustom","cutToFirstSignificantSubdomainCustomWithWWW","cutToFirstSignificantSubdomainWithWWW","cutURLParameter","cutWWW","dateTime64ToSnowflake","dateTimeToSnowflake","dateTrunc","decodeURLComponent","decodeXMLComponent","decrypt","defaultProfiles","defaultRoles","defaultValueOfArgumentType","defaultValueOfTypeName","deltaSum","deltaSumTimestamp","demangle","dictGet","dictGetChildren","dictGetDate","dictGetDateOrDefault","dictGetDateTime","dictGetDateTimeOrDefault","dictGetDescendants","dictGetFloat32","dictGetFloat32OrDefault","dictGetFloat64","dictGetFloat64OrDefault","dictGetHierarchy","dictGetInt8","dictGetInt8OrDefault","dictGetInt16","dictGetInt16OrDefault","dictGetInt32","dictGetInt32OrDefault","dictGetInt64","dictGetInt64OrDefault","dictGetOrDefault","dictGetOrNull","dictGetString","dictGetStringOrDefault","dictGetUInt8","dictGetUInt8OrDefault","dictGetUInt16","dictGetUInt16OrDefault","dictGetUInt32","dictGetUInt32OrDefault","dictGetUInt64","dictGetUInt64OrDefault","dictGetUUID","dictGetUUIDOrDefault","dictHas","dictIsIn","divide","domain","domainWithoutWWW","dumpColumnStructure","e","empty","emptyArrayDate","emptyArrayDateTime","emptyArrayFloat32","emptyArrayFloat64","emptyArrayInt8","emptyArrayInt16","emptyArrayInt32","emptyArrayInt64","emptyArrayString","emptyArrayToSingle","emptyArrayUInt8","emptyArrayUInt16","emptyArrayUInt32","emptyArrayUInt64","enabledProfiles","enabledRoles","encodeXMLComponent","encrypt","endsWith","entropy","equals","erf","erfc","errorCodeToName","evalMLMethod","exp2","exp10","extract","extractAll","extractAllGroups","extractAllGroupsHorizontal","extractAllGroupsVertical","extractGroups","extractTextFromHTML","extractURLParameter","extractURLParameterNames","extractURLParameters","farmFingerprint64","farmHash64","file","filesystemAvailable","filesystemCapacity","filesystemFree","finalizeAggregation","firstSignificantSubdomain","firstSignificantSubdomainCustom","format","formatDateTime","formatReadableQuantity","formatReadableSize","formatReadableTimeDelta","formatRow","formatRowNoNewline","fragment","FROM_UNIXTIME","fromModifiedJulianDay","fromModifiedJulianDayOrNull","fromUnixTimestamp","fromUnixTimestamp64Micro","fromUnixTimestamp64Milli","fromUnixTimestamp64Nano","fullHostName","fuzzBits","gcd","generateUUIDv4","geoDistance","geohashDecode","geohashEncode","geohashesInBox","geoToH3","getMacro","getServerPort","getSetting","getSizeOfEnumType","globalIn","globalInIgnoreSet","globalNotIn","globalNotInIgnoreSet","globalNotNullIn","globalNotNullInIgnoreSet","globalNullIn","globalNullInIgnoreSet","globalVariable","greatCircleAngle","greatCircleDistance","greater","greaterOrEquals","groupArray","groupArrayInsertAt","groupArrayMovingAvg","groupArrayMovingSum","groupArraySample","groupBitAnd","groupBitOr","groupBitXor","groupUniqArray","h3EdgeAngle","h3EdgeLengthM","h3GetBaseCell","h3GetResolution","h3HexAreaM2","h3IndexesAreNeighbors","h3IsValid","h3kRing","h3ToChildren","h3ToGeo","h3ToParent","h3ToString","halfMD5","has","hasAll","hasAny","hasColumnInTable","hasSubstr","hasThreadFuzzer","hasToken","hasTokenCaseInsensitive","histogram","hiveHash","hostName","hostname","identity","ifNotFinite","ignore","ilike","in","indexHint","indexOf","inIgnoreSet","initializeAggregation","initialQueryID","intDiv","intDivOrZero","intervalLengthSum","intExp2","intExp10","intHash32","intHash64","IPv4CIDRToRange","IPv4NumToString","IPv4NumToStringClassC","IPv4StringToNum","IPv4ToIPv6","IPv6CIDRToRange","IPv6NumToString","IPv6StringToNum","isConstant","isDecimalOverflow","isFinite","isInfinite","isIPAddressInRange","isIPv4String","isIPv6String","isNaN","isNotNull","isValidJSON","isValidUTF8","isZeroOrNull","javaHash","javaHashUTF16LE","joinGet","joinGetOrNull","JSON_EXISTS","JSON_QUERY","JSON_VALUE","JSONExtract","JSONExtractArrayRaw","JSONExtractBool","JSONExtractFloat","JSONExtractInt","JSONExtractKeysAndValues","JSONExtractKeysAndValuesRaw","JSONExtractRaw","JSONExtractString","JSONExtractUInt","JSONHas","JSONKey","JSONLength","JSONType","jumpConsistentHash","kurtPop","kurtSamp","lagInFrame","lcm","leadInFrame","leftPad","leftPadUTF8","lengthUTF8","less","lessOrEquals","lgamma","like","log1p","logTrace","lowCardinalityIndices","lowCardinalityKeys","lowerUTF8","MACNumToString","MACStringToNum","MACStringToOUI","mannWhitneyUTest","map","mapAdd","mapContains","mapKeys","mapPopulateSeries","mapSubtract","mapValues","match","materialize","maxIntersections","maxIntersectionsPosition","maxMap","MD5","median","medianBFloat16","medianBFloat16Weighted","medianDeterministic","medianExact","medianExactHigh","medianExactLow","medianExactWeighted","medianTDigest","medianTDigestWeighted","medianTiming","medianTimingWeighted","metroHash64","minMap","minus","modelEvaluate","modulo","moduloLegacy","moduloOrZero","multiFuzzyMatchAllIndices","multiFuzzyMatchAny","multiFuzzyMatchAnyIndex","multiIf","multiMatchAllIndices","multiMatchAny","multiMatchAnyIndex","multiply","multiSearchAllPositions","multiSearchAllPositionsCaseInsensitive","multiSearchAllPositionsCaseInsensitiveUTF8","multiSearchAllPositionsUTF8","multiSearchAny","multiSearchAnyCaseInsensitive","multiSearchAnyCaseInsensitiveUTF8","multiSearchAnyUTF8","multiSearchFirstIndex","multiSearchFirstIndexCaseInsensitive","multiSearchFirstIndexCaseInsensitiveUTF8","multiSearchFirstIndexUTF8","multiSearchFirstPosition","multiSearchFirstPositionCaseInsensitive","multiSearchFirstPositionCaseInsensitiveUTF8","multiSearchFirstPositionUTF8","negate","neighbor","netloc","ngramDistance","ngramDistanceCaseInsensitive","ngramDistanceCaseInsensitiveUTF8","ngramDistanceUTF8","ngramMinHash","ngramMinHashArg","ngramMinHashArgCaseInsensitive","ngramMinHashArgCaseInsensitiveUTF8","ngramMinHashArgUTF8","ngramMinHashCaseInsensitive","ngramMinHashCaseInsensitiveUTF8","ngramMinHashUTF8","ngramSearch","ngramSearchCaseInsensitive","ngramSearchCaseInsensitiveUTF8","ngramSearchUTF8","ngramSimHash","ngramSimHashCaseInsensitive","ngramSimHashCaseInsensitiveUTF8","ngramSimHashUTF8","normalizedQueryHash","normalizedQueryHashKeepNames","normalizeQuery","normalizeQueryKeepNames","notEmpty","notEquals","notILike","notIn","notInIgnoreSet","notLike","notNullIn","notNullInIgnoreSet","nullIn","nullInIgnoreSet","or","parseDateTime32BestEffort","parseDateTime32BestEffortOrNull","parseDateTime32BestEffortOrZero","parseDateTime64BestEffort","parseDateTime64BestEffortOrNull","parseDateTime64BestEffortOrZero","parseDateTimeBestEffort","parseDateTimeBestEffortOrNull","parseDateTimeBestEffortOrZero","parseDateTimeBestEffortUS","parseDateTimeBestEffortUSOrNull","parseDateTimeBestEffortUSOrZero","partitionId","path","pathFull","plus","pointInEllipses","pointInPolygon","polygonAreaCartesian","polygonAreaSpherical","polygonConvexHullCartesian","polygonPerimeterCartesian","polygonPerimeterSpherical","polygonsDistanceCartesian","polygonsDistanceSpherical","polygonsEqualsCartesian","polygonsIntersectionCartesian","polygonsIntersectionSpherical","polygonsSymDifferenceCartesian","polygonsSymDifferenceSpherical","polygonsUnionCartesian","polygonsUnionSpherical","polygonsWithinCartesian","polygonsWithinSpherical","port","positionCaseInsensitive","positionCaseInsensitiveUTF8","positionUTF8","protocol","quantile","quantileBFloat16","quantileBFloat16Weighted","quantileDeterministic","quantileExact","quantileExactExclusive","quantileExactHigh","quantileExactInclusive","quantileExactLow","quantileExactWeighted","quantiles","quantilesBFloat16","quantilesBFloat16Weighted","quantilesDeterministic","quantilesExact","quantilesExactExclusive","quantilesExactHigh","quantilesExactInclusive","quantilesExactLow","quantilesExactWeighted","quantilesTDigest","quantilesTDigestWeighted","quantilesTiming","quantilesTimingWeighted","quantileTDigest","quantileTDigestWeighted","quantileTiming","quantileTimingWeighted","queryID","queryString","queryStringAndFragment","rand32","rand64","randConstant","randomFixedString","randomPrintableASCII","randomString","randomStringUTF8","range","rankCorr","readWktMultiPolygon","readWktPoint","readWktPolygon","readWktRing","regexpQuoteMeta","regionHierarchy","regionIn","regionToArea","regionToCity","regionToContinent","regionToCountry","regionToDistrict","regionToName","regionToPopulation","regionToTopContinent","reinterpret","reinterpretAsDate","reinterpretAsDateTime","reinterpretAsFixedString","reinterpretAsFloat32","reinterpretAsFloat64","reinterpretAsInt8","reinterpretAsInt16","reinterpretAsInt32","reinterpretAsInt64","reinterpretAsInt128","reinterpretAsInt256","reinterpretAsString","reinterpretAsUInt8","reinterpretAsUInt16","reinterpretAsUInt32","reinterpretAsUInt64","reinterpretAsUInt128","reinterpretAsUInt256","reinterpretAsUUID","replaceAll","replaceOne","replaceRegexpAll","replaceRegexpOne","replicate","retention","reverseUTF8","rightPad","rightPadUTF8","roundAge","roundBankers","roundDown","roundDuration","roundToExp2","rowNumberInAllBlocks","rowNumberInBlock","runningAccumulate","runningConcurrency","runningDifference","runningDifferenceStartingWithFirstValue","sequenceCount","sequenceMatch","sequenceNextNode","serverUUID","SHA1","SHA224","SHA256","SHA512","shardCount","shardNum","sigmoid","simpleJSONExtractBool","simpleJSONExtractFloat","simpleJSONExtractInt","simpleJSONExtractRaw","simpleJSONExtractString","simpleJSONExtractUInt","simpleJSONHas","simpleLinearRegression","singleValueOrNull","sinh","sipHash64","sipHash128","skewPop","skewSamp","sleep","sleepEachRow","snowflakeToDateTime","snowflakeToDateTime64","splitByChar","splitByNonAlpha","splitByRegexp","splitByString","splitByWhitespace","startsWith","stddevPop","stddevPopStable","stddevSamp","stddevSampStable","stochasticLinearRegression","stochasticLogisticRegression","stringToH3","studentTTest","substringUTF8","subtractDays","subtractHours","subtractMinutes","subtractMonths","subtractQuarters","subtractSeconds","subtractWeeks","subtractYears","sumCount","sumKahan","sumMap","sumMapFiltered","sumMapFilteredWithOverflow","sumMapWithOverflow","sumWithOverflow","svg","tcpPort","tgamma","throwIf","tid","timeSlot","timeSlots","timeZone","timezone","timeZoneOf","timezoneOf","timeZoneOffset","timezoneOffset","toColumnTypeName","toDate","toDate32","toDate32OrNull","toDate32OrZero","toDateOrNull","toDateOrZero","toDateTime","toDateTime32","toDateTime64","toDateTime64OrNull","toDateTime64OrZero","toDateTimeOrNull","toDateTimeOrZero","today","toDayOfMonth","toDayOfWeek","toDayOfYear","toDecimal32","toDecimal32OrNull","toDecimal32OrZero","toDecimal64","toDecimal64OrNull","toDecimal64OrZero","toDecimal128","toDecimal128OrNull","toDecimal128OrZero","toDecimal256","toDecimal256OrNull","toDecimal256OrZero","toFixedString","toFloat32","toFloat32OrNull","toFloat32OrZero","toFloat64","toFloat64OrNull","toFloat64OrZero","toHour","toInt8","toInt8OrNull","toInt8OrZero","toInt16","toInt16OrNull","toInt16OrZero","toInt32","toInt32OrNull","toInt32OrZero","toInt64","toInt64OrNull","toInt64OrZero","toInt128","toInt128OrNull","toInt128OrZero","toInt256","toInt256OrNull","toInt256OrZero","toIntervalDay","toIntervalHour","toIntervalMinute","toIntervalMonth","toIntervalQuarter","toIntervalSecond","toIntervalWeek","toIntervalYear","toIPv4","toIPv6","toISOWeek","toISOYear","toJSONString","toLowCardinality","toMinute","toModifiedJulianDay","toModifiedJulianDayOrNull","toMonday","toMonth","toNullable","topK","topKWeighted","topLevelDomain","toQuarter","toRelativeDayNum","toRelativeHourNum","toRelativeMinuteNum","toRelativeMonthNum","toRelativeQuarterNum","toRelativeSecondNum","toRelativeWeekNum","toRelativeYearNum","toSecond","toStartOfDay","toStartOfFifteenMinutes","toStartOfFiveMinute","toStartOfHour","toStartOfInterval","toStartOfISOYear","toStartOfMinute","toStartOfMonth","toStartOfQuarter","toStartOfSecond","toStartOfTenMinutes","toStartOfWeek","toStartOfYear","toString","toStringCutToZero","toTime","toTimeZone","toTimezone","toTypeName","toUInt8","toUInt8OrNull","toUInt8OrZero","toUInt16","toUInt16OrNull","toUInt16OrZero","toUInt32","toUInt32OrNull","toUInt32OrZero","toUInt64","toUInt64OrNull","toUInt64OrZero","toUInt128","toUInt128OrNull","toUInt128OrZero","toUInt256","toUInt256OrNull","toUInt256OrZero","toUnixTimestamp","toUnixTimestamp64Micro","toUnixTimestamp64Milli","toUnixTimestamp64Nano","toUUID","toUUIDOrNull","toUUIDOrZero","toValidUTF8","toWeek","toYear","toYearWeek","toYYYYMM","toYYYYMMDD","toYYYYMMDDhhmmss","transform","trimBoth","trimLeft","trimRight","tryBase64Decode","tuple","tupleElement","tupleHammingDistance","tupleToNameValuePairs","uniq","uniqCombined","uniqCombined64","uniqExact","uniqHLL12","uniqUpTo","upperUTF8","uptime","URLHash","URLHierarchy","URLPathHierarchy","UUIDNumToString","UUIDStringToNum","validateNestedArraySizes","varPop","varPopStable","varSamp","varSampStable","visibleWidth","visitParamExtractBool","visitParamExtractFloat","visitParamExtractInt","visitParamExtractRaw","visitParamExtractString","visitParamExtractUInt","visitParamHas","welchTTest","windowFunnel","wkt","wordShingleMinHash","wordShingleMinHashArg","wordShingleMinHashArgCaseInsensitive","wordShingleMinHashArgCaseInsensitiveUTF8","wordShingleMinHashArgUTF8","wordShingleMinHashCaseInsensitive","wordShingleMinHashCaseInsensitiveUTF8","wordShingleMinHashUTF8","wordShingleSimHash","wordShingleSimHashCaseInsensitive","wordShingleSimHashCaseInsensitiveUTF8","wordShingleSimHashUTF8","xor","xxHash32","xxHash64","yandexConsistentHash","yesterday","YPathArrayBoolean","YPathArrayBooleanStrict","YPathArrayDouble","YPathArrayDoubleStrict","YPathArrayInt64","YPathArrayInt64Strict","YPathArrayUInt64","YPathArrayUInt64Strict","YPathBoolean","YPathBooleanStrict","YPathDouble","YPathDoubleStrict","YPathExtract","YPathExtractStrict","YPathInt64","YPathInt64Strict","YPathRaw","YPathRawStrict","YPathString","YPathStringStrict","YPathUInt64","YPathUInt64Strict","YSONExtract","YSONExtractArrayRaw","YSONExtractBool","YSONExtractFloat","YSONExtractInt","YSONExtractKeysAndValues","YSONExtractKeysAndValuesRaw","YSONExtractRaw","YSONExtractString","YSONExtractUInt","YSONHas","YSONKey","YSONLength","YSONType"],o=["_CAST","abs","acos","asin","atan","atan2","avg","bin","BIT_AND","BIT_OR","BIT_XOR","CAST","ceil","ceiling","char","CHAR_LENGTH","CHARACTER_LENGTH","coalesce","concat","connection_id","connectionId","corr","cos","count","countSubstrings","COVAR_POP","COVAR_SAMP","CRC32","CRC32IEEE","CRC64","DATABASE","DATE","date_trunc","dateDiff","dateName","DAY","DAYOFMONTH","DAYOFWEEK","DAYOFYEAR","dense_rank","exp","first_value","flatten","floor","FQDN","FROM_BASE64","greatest","hex","HOUR","hypot","if","ifNull","INET6_ATON","INET6_NTOA","INET_ATON","INET_NTOA","initial_query_id","isNull","last_value","lcase","least","length","ln","locate","log","log2","log10","lower","lpad","max","mid","min","MINUTE","mod","MONTH","not","now","now64","nth_value","nullIf","pi","position","pow","power","QUARTER","query_id","rand","rank","repeat","replace","reverse","round","row_number","rpad","SECOND","sign","sin","sqrt","STDDEV_POP","STDDEV_SAMP","substr","substring","sum","tan","tanh","TO_BASE64","trunc","truncate","ucase","unbin","unhex","upper","user","VAR_POP","VAR_SAMP","version","week","YEAR","yearweek"],s=["cluster","clusterAllReplicas","concatYtTables","concatYtTablesLike","concatYtTablesRange","concatYtTablesRegexp","dictionary","executable","file","generateRandom","input","jdbc","merge","null","numbers","numbers_mt","odbc","remote","remoteSecure","url","values","view","ytSubquery","zeros","zeros_mt"],l=["Buffer","Memory","YtTable"],c=["AggregateFunction","Array","Enum8","Enum16","FixedString","Float32","Float64","Int8","Int16","Int32","Int64","Int128","Int256","IntervalDay","IntervalHour","IntervalMinute","IntervalMonth","IntervalQuarter","IntervalSecond","IntervalWeek","IntervalYear","IPv4","IPv6","LowCardinality","Map","MultiPolygon","Nested","Nothing","Nullable","Point","Polygon","Ring","SimpleAggregateFunction","String","Tuple","UInt8","UInt16","UInt32","UInt64","UInt128","UInt256","UUID","YtBoolean"],u=["BIGINT","BIGINT SIGNED","BIGINT UNSIGNED","BINARY","BINARY LARGE OBJECT","BINARY VARYING","BLOB","BOOL","BOOLEAN","BYTE","BYTEA","CHAR","CHAR LARGE OBJECT","CHAR VARYING","CHARACTER","CHARACTER LARGE OBJECT","CHARACTER VARYING","CLOB","DEC","DOUBLE","DOUBLE PRECISION","Date","Date32","DateTime","DateTime32","DateTime64","Decimal","Decimal128","Decimal256","Decimal32","Decimal64","ENUM","Enum","FIXED","FLOAT","INET4","INET6","INT","INT SIGNED","INT UNSIGNED","INT1","INT1 SIGNED","INT1 UNSIGNED","INTEGER","INTEGER SIGNED","INTEGER UNSIGNED","LONGBLOB","LONGTEXT","MEDIUMBLOB","MEDIUMINT","MEDIUMINT SIGNED","MEDIUMINT UNSIGNED","MEDIUMTEXT","NATIONAL CHAR","NATIONAL CHAR VARYING","NATIONAL CHARACTER","NATIONAL CHARACTER LARGE OBJECT","NATIONAL CHARACTER VARYING","NCHAR","NCHAR LARGE OBJECT","NCHAR VARYING","NUMERIC","NVARCHAR","REAL","SINGLE","SMALLINT","SMALLINT SIGNED","SMALLINT UNSIGNED","TEXT","TIMESTAMP","TINYBLOB","TINYINT","TINYINT SIGNED","TINYINT UNSIGNED","TINYTEXT","VARCHAR","VARCHAR2"],m={keywordList:r.concat(["GROUP BY","ON CLUSTER","ORDER BY","LIMIT","RENAME TABLE","IF NOT EXISTS","IF EXISTS","FORMAT Vertical","FORMAT JSONCompact","FORMAT JSONEachRow","FORMAT TSKV","FORMAT TabSeparatedWithNames","FORMAT TabSeparatedWithNamesAndTypes","FORMAT TabSeparatedRaw","FORMAT BlockTabSeparated","FORMAT CSVWithNames","FORMAT CSV","FORMAT JSON","FORMAT TabSeparated"]),constantList:n,typeParameterList:c.concat(u,l),functionList:i.concat(o,s)},I={comments:{lineComment:"--",blockComment:["```","```"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"`",close:"`",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},T=A(r),S=A(u.filter((t=>/^\S*$/.test(t))));const d=A(o),g={defaultToken:"text",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"}],keywords:r,keywordsDouble:[`${p("GROUP")}\\W+${p("BY")}`,`${p("ON")}\\W+${p("CLUSTER")}`,`${p("ORDER")}\\W+${p("BY")}`,`${p("LIMIT")}\\W+\\d+\\W*,\\W*\\d+`,`${p("LIMIT")}\\W+\\d+\\W+${p("BY")}\\W+`,`${p("LIMIT")}\\W+\\d+`,`${p("RENAME")}\\W+${p("TABLE")}`,`${p("IF")}\\W+${p("NOT")}\\W+${p("EXISTS")}`,`${p("IF")}\\W+${p("EXISTS")}`,`${p("FORMAT")}\\W+Vertical`,`${p("FORMAT")}\\W+JSONCompact`,`${p("FORMAT")}\\W+JSONEachRow`,`${p("FORMAT")}\\W+TSKV`,`${p("FORMAT")}\\W+TabSeparatedWithNames`,`${p("FORMAT")}\\W+TabSeparatedWithNamesAndTypes`,`${p("FORMAT")}\\W+TabSeparatedRaw`,`${p("FORMAT")}\\W+BlockTabSeparated`,`${p("FORMAT")}\\W+CSVWithNames`,`${p("FORMAT")}\\W+CSV`,`${p("FORMAT")}\\W+JSON`,`${p("FORMAT")}\\W+TabSeparated`].join("|"),typeKeywords:c,typeKeywordsDouble:A(function(t){return t.filter((t=>/\s/.test(t))).sort(((t,e)=>e.localeCompare(t)))}(u)),constants:n,builtinFunctions:i,tableFunctions:s,tableEngines:l,operators:["+","-","/","//","%","<@>","@>","<@","&","^","~","<",">","<=","=>","==","!=","<>","="],symbols:/[=>\w+)?/,tokenizer:{root:[{include:"@whitespace"},{include:"@comments"},{include:"@numbers"},{include:"@strings"},[/[$@:](@variables)/,"variable"],[/{(@variables)}/,"variable"],[/[?;,.]/,"delimiter"],[/[(){}[\]]/,"@brackets"],[/@keywordsDouble/,"keyword"],[/@typeKeywordsDouble/,"keyword.type"],[/[a-zA-Z_$][\w$]*/,{cases:{[T]:{token:"keyword"},"@constants":{token:"constant"},"@builtinFunctions":{token:"constant.other.color"},[d]:{token:"constant.other.color"},"@tableFunctions":{token:"constant.other.color"},"@tableEngines":{token:"constant.other.color"},"@typeKeywords":{token:"keyword.type"},[S]:{token:"keyword.type"},"@default":"identifier"}}],[/@symbols/,{cases:{"@operators":"operator.sql","@default":""}}]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/```/,{token:"comment.quote",next:"@comment"}],[/\/\*/,{token:"comment.quote",next:"@cppComment"}]],comment:[[/[^`]+/,"comment"],[/```/,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],cppComment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],numbers:[[/[+-]?\d+(?:(?:\.\d*)?(?:[eE][+-]?\d+)?)?\b/,"number"]],strings:[[/'/,{token:"string",next:"@stringSingle"}],[/"/,{token:"string.tablepath",next:"@stringDouble"}],[/`/,{token:"string.tablepath",next:"@stringBacktick"}]],stringSingle:[[/[^\\']/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/'/,{token:"string",next:"@pop"}]],stringDouble:[[/[^\\"]/,"string.tablepath"],[/@escapes/,"string.tablepath"],[/\\./,"string.tablepath"],[/"/,{token:"string.tablepath",next:"@pop"}]],stringBacktick:[[/[^\\`]/,"string.tablepath"],[/@escapes/,"string.tablepath"],[/\\./,"string.tablepath"],[/`/,{token:"string.tablepath",next:"@pop"}]]}};function p(t){return t.split("").map((t=>/[a-zA-Z]/.test(t)?`[${t.toLowerCase()}${t.toUpperCase()}]`:t)).join("")}function A(t){return`(${t.map((t=>p(t).replace(/\s+/g,"\\s"))).join("|")})`}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6405.b0dd94a9.chunk.js b/ydb/core/viewer/monitoring/static/js/6405.b0dd94a9.chunk.js deleted file mode 100644 index 6002a58e51b8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6405.b0dd94a9.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6405],{56405:function(e,t,n){!function(e,t){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var r=n(t),u={1:"\u0661",2:"\u0662",3:"\u0663",4:"\u0664",5:"\u0665",6:"\u0666",7:"\u0667",8:"\u0668",9:"\u0669",0:"\u0660"},d={"\u0661":"1","\u0662":"2","\u0663":"3","\u0664":"4","\u0665":"5","\u0666":"6","\u0667":"7","\u0668":"8","\u0669":"9","\u0660":"0"},a=["\u06a9\u0627\u0646\u0648\u0648\u0646\u06cc \u062f\u0648\u0648\u06d5\u0645","\u0634\u0648\u0628\u0627\u062a","\u0626\u0627\u062f\u0627\u0631","\u0646\u06cc\u0633\u0627\u0646","\u0626\u0627\u06cc\u0627\u0631","\u062d\u0648\u0632\u06d5\u06cc\u0631\u0627\u0646","\u062a\u06d5\u0645\u0645\u0648\u0648\u0632","\u0626\u0627\u0628","\u0626\u06d5\u06cc\u0644\u0648\u0648\u0644","\u062a\u0634\u0631\u06cc\u0646\u06cc \u06cc\u06d5\u06a9\u06d5\u0645","\u062a\u0634\u0631\u06cc\u0646\u06cc \u062f\u0648\u0648\u06d5\u0645","\u06a9\u0627\u0646\u0648\u0648\u0646\u06cc \u06cc\u06d5\u06a9\u06d5\u0645"],i={name:"ku",months:a,monthsShort:a,weekdays:"\u06cc\u06d5\u06a9\u0634\u06d5\u0645\u0645\u06d5_\u062f\u0648\u0648\u0634\u06d5\u0645\u0645\u06d5_\u0633\u06ce\u0634\u06d5\u0645\u0645\u06d5_\u0686\u0648\u0627\u0631\u0634\u06d5\u0645\u0645\u06d5_\u067e\u06ce\u0646\u062c\u0634\u06d5\u0645\u0645\u06d5_\u0647\u06d5\u06cc\u0646\u06cc_\u0634\u06d5\u0645\u0645\u06d5".split("_"),weekdaysShort:"\u06cc\u06d5\u06a9\u0634\u06d5\u0645_\u062f\u0648\u0648\u0634\u06d5\u0645_\u0633\u06ce\u0634\u06d5\u0645_\u0686\u0648\u0627\u0631\u0634\u06d5\u0645_\u067e\u06ce\u0646\u062c\u0634\u06d5\u0645_\u0647\u06d5\u06cc\u0646\u06cc_\u0634\u06d5\u0645\u0645\u06d5".split("_"),weekStart:6,weekdaysMin:"\u06cc_\u062f_\u0633_\u0686_\u067e_\u0647\u0640_\u0634".split("_"),preparse:function(e){return e.replace(/[\u0661\u0662\u0663\u0664\u0665\u0666\u0667\u0668\u0669\u0660]/g,(function(e){return d[e]})).replace(/\u060c/g,",")},postformat:function(e){return e.replace(/\d/g,(function(e){return u[e]})).replace(/,/g,"\u060c")},ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},meridiem:function(e){return e<12?"\u067e.\u0646":"\u062f.\u0646"},relativeTime:{future:"\u0644\u06d5 %s",past:"\u0644\u06d5\u0645\u06d5\u0648\u067e\u06ce\u0634 %s",s:"\u0686\u06d5\u0646\u062f \u0686\u0631\u06a9\u06d5\u06cc\u06d5\u06a9",m:"\u06cc\u06d5\u06a9 \u062e\u0648\u0644\u06d5\u06a9",mm:"%d \u062e\u0648\u0644\u06d5\u06a9",h:"\u06cc\u06d5\u06a9 \u06a9\u0627\u062a\u0698\u0645\u06ce\u0631",hh:"%d \u06a9\u0627\u062a\u0698\u0645\u06ce\u0631",d:"\u06cc\u06d5\u06a9 \u0695\u06c6\u0698",dd:"%d \u0695\u06c6\u0698",M:"\u06cc\u06d5\u06a9 \u0645\u0627\u0646\u06af",MM:"%d \u0645\u0627\u0646\u06af",y:"\u06cc\u06d5\u06a9 \u0633\u0627\u06b5",yy:"%d \u0633\u0627\u06b5"}};r.default.locale(i,null,!0),e.default=i,e.englishToArabicNumbersMap=u,Object.defineProperty(e,"__esModule",{value:!0})}(t,n(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6447.2c0d9bda.chunk.js b/ydb/core/viewer/monitoring/static/js/6447.2c0d9bda.chunk.js deleted file mode 100644 index 5c3c6d7042bb..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6447.2c0d9bda.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6447.2c0d9bda.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6447],{66447:(e,t,n)=>{n.r(t),n.d(t,{CompletionAdapter:()=>Wt,DefinitionAdapter:()=>Zt,DiagnosticsAdapter:()=>Vt,DocumentColorAdapter:()=>ln,DocumentFormattingEditProvider:()=>cn,DocumentHighlightAdapter:()=>Gt,DocumentLinkAdapter:()=>sn,DocumentRangeFormattingEditProvider:()=>un,DocumentSymbolAdapter:()=>rn,FoldingRangeAdapter:()=>gn,HoverAdapter:()=>$t,ReferenceAdapter:()=>tn,RenameAdapter:()=>nn,SelectionRangeAdapter:()=>pn,WorkerManager:()=>Nt,fromPosition:()=>Kt,fromRange:()=>Ht,getWorker:()=>Kn,setupMode:()=>Xn,toRange:()=>Xt,toTextEdit:()=>qt});var r,i,o=n(80781),a=Object.defineProperty,s=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,u=Object.prototype.hasOwnProperty,d=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of c(t))u.call(e,i)||i===n||a(e,i,{get:()=>t[i],enumerable:!(r=s(t,i))||r.enumerable});return e},l={};d(l,r=o,"default"),i&&d(i,r,"default");var g,f,h,p,m,v,b,k,C,_,w,y,x,E,I,A,S,T,L,R,M,F,P,j,D,N,O,U,V,B,W,K,H,X,z,q,$,Q,J,G,Y,Z,ee,te,ne,re,ie,oe,ae,se,ce,ue,de,le,ge,fe,he,pe,me,ve,be,ke,Ce,_e,we,ye,xe,Ee,Ie,Ae,Se,Te,Le,Re,Me,Fe,Pe,je,De,Ne,Oe,Ue,Ve,Be,We,Ke,He,Xe,ze,qe,$e,Qe,Je,Ge,Ye,Ze,et,tt,nt,rt,it,ot,at,st,ct,ut,dt,lt,gt,ft,ht,pt,mt,vt,bt,kt,Ct,_t,wt,yt,xt,Et,It,At,St,Tt,Lt,Rt,Mt,Ft,Pt,jt,Dt,Nt=class{constructor(e){this._defaults=e,this._worker=null,this._client=null,this._idleCheckInterval=window.setInterval((()=>this._checkIfIdle()),3e4),this._lastUsedTime=0,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker()))}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}dispose(){clearInterval(this._idleCheckInterval),this._configChangeListener.dispose(),this._stopWorker()}_checkIfIdle(){if(!this._worker)return;Date.now()-this._lastUsedTime>12e4&&this._stopWorker()}_getClient(){return this._lastUsedTime=Date.now(),this._client||(this._worker=l.editor.createWebWorker({moduleId:"vs/language/json/jsonWorker",label:this._defaults.languageId,createData:{languageSettings:this._defaults.diagnosticsOptions,languageId:this._defaults.languageId,enableSchemaRequest:this._defaults.diagnosticsOptions.enableSchemaRequest}}),this._client=this._worker.getProxy()),this._client}getLanguageServiceWorker(...e){let t;return this._getClient().then((e=>{t=e})).then((t=>{if(this._worker)return this._worker.withSyncedResources(e)})).then((e=>t))}};(g||(g={})).is=function(e){return"string"===typeof e},(f||(f={})).is=function(e){return"string"===typeof e},(p=h||(h={})).MIN_VALUE=-2147483648,p.MAX_VALUE=2147483647,p.is=function(e){return"number"===typeof e&&p.MIN_VALUE<=e&&e<=p.MAX_VALUE},(v=m||(m={})).MIN_VALUE=0,v.MAX_VALUE=2147483647,v.is=function(e){return"number"===typeof e&&v.MIN_VALUE<=e&&e<=v.MAX_VALUE},(k=b||(b={})).create=function(e,t){return e===Number.MAX_VALUE&&(e=m.MAX_VALUE),t===Number.MAX_VALUE&&(t=m.MAX_VALUE),{line:e,character:t}},k.is=function(e){let t=e;return Ot.objectLiteral(t)&&Ot.uinteger(t.line)&&Ot.uinteger(t.character)},(_=C||(C={})).create=function(e,t,n,r){if(Ot.uinteger(e)&&Ot.uinteger(t)&&Ot.uinteger(n)&&Ot.uinteger(r))return{start:b.create(e,t),end:b.create(n,r)};if(b.is(e)&&b.is(t))return{start:e,end:t};throw new Error(`Range#create called with invalid arguments[${e}, ${t}, ${n}, ${r}]`)},_.is=function(e){let t=e;return Ot.objectLiteral(t)&&b.is(t.start)&&b.is(t.end)},(y=w||(w={})).create=function(e,t){return{uri:e,range:t}},y.is=function(e){let t=e;return Ot.objectLiteral(t)&&C.is(t.range)&&(Ot.string(t.uri)||Ot.undefined(t.uri))},(E=x||(x={})).create=function(e,t,n,r){return{targetUri:e,targetRange:t,targetSelectionRange:n,originSelectionRange:r}},E.is=function(e){let t=e;return Ot.objectLiteral(t)&&C.is(t.targetRange)&&Ot.string(t.targetUri)&&C.is(t.targetSelectionRange)&&(C.is(t.originSelectionRange)||Ot.undefined(t.originSelectionRange))},(A=I||(I={})).create=function(e,t,n,r){return{red:e,green:t,blue:n,alpha:r}},A.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.numberRange(t.red,0,1)&&Ot.numberRange(t.green,0,1)&&Ot.numberRange(t.blue,0,1)&&Ot.numberRange(t.alpha,0,1)},(T=S||(S={})).create=function(e,t){return{range:e,color:t}},T.is=function(e){const t=e;return Ot.objectLiteral(t)&&C.is(t.range)&&I.is(t.color)},(R=L||(L={})).create=function(e,t,n){return{label:e,textEdit:t,additionalTextEdits:n}},R.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.label)&&(Ot.undefined(t.textEdit)||q.is(t))&&(Ot.undefined(t.additionalTextEdits)||Ot.typedArray(t.additionalTextEdits,q.is))},(F=M||(M={})).Comment="comment",F.Imports="imports",F.Region="region",(j=P||(P={})).create=function(e,t,n,r,i,o){const a={startLine:e,endLine:t};return Ot.defined(n)&&(a.startCharacter=n),Ot.defined(r)&&(a.endCharacter=r),Ot.defined(i)&&(a.kind=i),Ot.defined(o)&&(a.collapsedText=o),a},j.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.uinteger(t.startLine)&&Ot.uinteger(t.startLine)&&(Ot.undefined(t.startCharacter)||Ot.uinteger(t.startCharacter))&&(Ot.undefined(t.endCharacter)||Ot.uinteger(t.endCharacter))&&(Ot.undefined(t.kind)||Ot.string(t.kind))},(N=D||(D={})).create=function(e,t){return{location:e,message:t}},N.is=function(e){let t=e;return Ot.defined(t)&&w.is(t.location)&&Ot.string(t.message)},(U=O||(O={})).Error=1,U.Warning=2,U.Information=3,U.Hint=4,(B=V||(V={})).Unnecessary=1,B.Deprecated=2,(W||(W={})).is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.href)},(H=K||(K={})).create=function(e,t,n,r,i,o){let a={range:e,message:t};return Ot.defined(n)&&(a.severity=n),Ot.defined(r)&&(a.code=r),Ot.defined(i)&&(a.source=i),Ot.defined(o)&&(a.relatedInformation=o),a},H.is=function(e){var t;let n=e;return Ot.defined(n)&&C.is(n.range)&&Ot.string(n.message)&&(Ot.number(n.severity)||Ot.undefined(n.severity))&&(Ot.integer(n.code)||Ot.string(n.code)||Ot.undefined(n.code))&&(Ot.undefined(n.codeDescription)||Ot.string(null===(t=n.codeDescription)||void 0===t?void 0:t.href))&&(Ot.string(n.source)||Ot.undefined(n.source))&&(Ot.undefined(n.relatedInformation)||Ot.typedArray(n.relatedInformation,D.is))},(z=X||(X={})).create=function(e,t,...n){let r={title:e,command:t};return Ot.defined(n)&&n.length>0&&(r.arguments=n),r},z.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.title)&&Ot.string(t.command)},($=q||(q={})).replace=function(e,t){return{range:e,newText:t}},$.insert=function(e,t){return{range:{start:e,end:e},newText:t}},$.del=function(e){return{range:e,newText:""}},$.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.newText)&&C.is(t.range)},(J=Q||(Q={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},J.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.label)&&(Ot.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(Ot.string(t.description)||void 0===t.description)},(G||(G={})).is=function(e){const t=e;return Ot.string(t)},(Z=Y||(Y={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},Z.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},Z.del=function(e,t){return{range:e,newText:"",annotationId:t}},Z.is=function(e){const t=e;return q.is(t)&&(Q.is(t.annotationId)||G.is(t.annotationId))},(te=ee||(ee={})).create=function(e,t){return{textDocument:e,edits:t}},te.is=function(e){let t=e;return Ot.defined(t)&&fe.is(t.textDocument)&&Array.isArray(t.edits)},(re=ne||(ne={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},re.is=function(e){let t=e;return t&&"create"===t.kind&&Ot.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||Ot.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ot.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||G.is(t.annotationId))},(oe=ie||(ie={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},oe.is=function(e){let t=e;return t&&"rename"===t.kind&&Ot.string(t.oldUri)&&Ot.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||Ot.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ot.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||G.is(t.annotationId))},(se=ae||(ae={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},se.is=function(e){let t=e;return t&&"delete"===t.kind&&Ot.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||Ot.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||Ot.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||G.is(t.annotationId))},(ce||(ce={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>Ot.string(e.kind)?ne.is(e)||ie.is(e)||ae.is(e):ee.is(e))))},(de=ue||(ue={})).create=function(e){return{uri:e}},de.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)},(ge=le||(le={})).create=function(e,t){return{uri:e,version:t}},ge.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)&&Ot.integer(t.version)},(he=fe||(fe={})).create=function(e,t){return{uri:e,version:t}},he.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)&&(null===t.version||Ot.integer(t.version))},(me=pe||(pe={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},me.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)&&Ot.string(t.languageId)&&Ot.integer(t.version)&&Ot.string(t.text)},(be=ve||(ve={})).PlainText="plaintext",be.Markdown="markdown",be.is=function(e){const t=e;return t===be.PlainText||t===be.Markdown},(ke||(ke={})).is=function(e){const t=e;return Ot.objectLiteral(e)&&ve.is(t.kind)&&Ot.string(t.value)},(_e=Ce||(Ce={})).Text=1,_e.Method=2,_e.Function=3,_e.Constructor=4,_e.Field=5,_e.Variable=6,_e.Class=7,_e.Interface=8,_e.Module=9,_e.Property=10,_e.Unit=11,_e.Value=12,_e.Enum=13,_e.Keyword=14,_e.Snippet=15,_e.Color=16,_e.File=17,_e.Reference=18,_e.Folder=19,_e.EnumMember=20,_e.Constant=21,_e.Struct=22,_e.Event=23,_e.Operator=24,_e.TypeParameter=25,(ye=we||(we={})).PlainText=1,ye.Snippet=2,(xe||(xe={})).Deprecated=1,(Ie=Ee||(Ee={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},Ie.is=function(e){const t=e;return t&&Ot.string(t.newText)&&C.is(t.insert)&&C.is(t.replace)},(Se=Ae||(Ae={})).asIs=1,Se.adjustIndentation=2,(Te||(Te={})).is=function(e){const t=e;return t&&(Ot.string(t.detail)||void 0===t.detail)&&(Ot.string(t.description)||void 0===t.description)},(Le||(Le={})).create=function(e){return{label:e}},(Re||(Re={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(Fe=Me||(Me={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},Fe.is=function(e){const t=e;return Ot.string(t)||Ot.objectLiteral(t)&&Ot.string(t.language)&&Ot.string(t.value)},(Pe||(Pe={})).is=function(e){let t=e;return!!t&&Ot.objectLiteral(t)&&(ke.is(t.contents)||Me.is(t.contents)||Ot.typedArray(t.contents,Me.is))&&(void 0===e.range||C.is(e.range))},(je||(je={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(De||(De={})).create=function(e,t,...n){let r={label:e};return Ot.defined(t)&&(r.documentation=t),Ot.defined(n)?r.parameters=n:r.parameters=[],r},(Oe=Ne||(Ne={})).Text=1,Oe.Read=2,Oe.Write=3,(Ue||(Ue={})).create=function(e,t){let n={range:e};return Ot.number(t)&&(n.kind=t),n},(Be=Ve||(Ve={})).File=1,Be.Module=2,Be.Namespace=3,Be.Package=4,Be.Class=5,Be.Method=6,Be.Property=7,Be.Field=8,Be.Constructor=9,Be.Enum=10,Be.Interface=11,Be.Function=12,Be.Variable=13,Be.Constant=14,Be.String=15,Be.Number=16,Be.Boolean=17,Be.Array=18,Be.Object=19,Be.Key=20,Be.Null=21,Be.EnumMember=22,Be.Struct=23,Be.Event=24,Be.Operator=25,Be.TypeParameter=26,(We||(We={})).Deprecated=1,(Ke||(Ke={})).create=function(e,t,n,r,i){let o={name:e,kind:t,location:{uri:r,range:n}};return i&&(o.containerName=i),o},(He||(He={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},(ze=Xe||(Xe={})).create=function(e,t,n,r,i,o){let a={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==o&&(a.children=o),a},ze.is=function(e){let t=e;return t&&Ot.string(t.name)&&Ot.number(t.kind)&&C.is(t.range)&&C.is(t.selectionRange)&&(void 0===t.detail||Ot.string(t.detail))&&(void 0===t.deprecated||Ot.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},($e=qe||(qe={})).Empty="",$e.QuickFix="quickfix",$e.Refactor="refactor",$e.RefactorExtract="refactor.extract",$e.RefactorInline="refactor.inline",$e.RefactorRewrite="refactor.rewrite",$e.Source="source",$e.SourceOrganizeImports="source.organizeImports",$e.SourceFixAll="source.fixAll",(Je=Qe||(Qe={})).Invoked=1,Je.Automatic=2,(Ye=Ge||(Ge={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},Ye.is=function(e){let t=e;return Ot.defined(t)&&Ot.typedArray(t.diagnostics,K.is)&&(void 0===t.only||Ot.typedArray(t.only,Ot.string))&&(void 0===t.triggerKind||t.triggerKind===Qe.Invoked||t.triggerKind===Qe.Automatic)},(et=Ze||(Ze={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):X.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},et.is=function(e){let t=e;return t&&Ot.string(t.title)&&(void 0===t.diagnostics||Ot.typedArray(t.diagnostics,K.is))&&(void 0===t.kind||Ot.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||X.is(t.command))&&(void 0===t.isPreferred||Ot.boolean(t.isPreferred))&&(void 0===t.edit||ce.is(t.edit))},(nt=tt||(tt={})).create=function(e,t){let n={range:e};return Ot.defined(t)&&(n.data=t),n},nt.is=function(e){let t=e;return Ot.defined(t)&&C.is(t.range)&&(Ot.undefined(t.command)||X.is(t.command))},(it=rt||(rt={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},it.is=function(e){let t=e;return Ot.defined(t)&&Ot.uinteger(t.tabSize)&&Ot.boolean(t.insertSpaces)},(at=ot||(ot={})).create=function(e,t,n){return{range:e,target:t,data:n}},at.is=function(e){let t=e;return Ot.defined(t)&&C.is(t.range)&&(Ot.undefined(t.target)||Ot.string(t.target))},(ct=st||(st={})).create=function(e,t){return{range:e,parent:t}},ct.is=function(e){let t=e;return Ot.objectLiteral(t)&&C.is(t.range)&&(void 0===t.parent||ct.is(t.parent))},(dt=ut||(ut={})).namespace="namespace",dt.type="type",dt.class="class",dt.enum="enum",dt.interface="interface",dt.struct="struct",dt.typeParameter="typeParameter",dt.parameter="parameter",dt.variable="variable",dt.property="property",dt.enumMember="enumMember",dt.event="event",dt.function="function",dt.method="method",dt.macro="macro",dt.keyword="keyword",dt.modifier="modifier",dt.comment="comment",dt.string="string",dt.number="number",dt.regexp="regexp",dt.operator="operator",dt.decorator="decorator",(gt=lt||(lt={})).declaration="declaration",gt.definition="definition",gt.readonly="readonly",gt.static="static",gt.deprecated="deprecated",gt.abstract="abstract",gt.async="async",gt.modification="modification",gt.documentation="documentation",gt.defaultLibrary="defaultLibrary",(ft||(ft={})).is=function(e){const t=e;return Ot.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(pt=ht||(ht={})).create=function(e,t){return{range:e,text:t}},pt.is=function(e){const t=e;return void 0!==t&&null!==t&&C.is(t.range)&&Ot.string(t.text)},(vt=mt||(mt={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},vt.is=function(e){const t=e;return void 0!==t&&null!==t&&C.is(t.range)&&Ot.boolean(t.caseSensitiveLookup)&&(Ot.string(t.variableName)||void 0===t.variableName)},(kt=bt||(bt={})).create=function(e,t){return{range:e,expression:t}},kt.is=function(e){const t=e;return void 0!==t&&null!==t&&C.is(t.range)&&(Ot.string(t.expression)||void 0===t.expression)},(_t=Ct||(Ct={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},_t.is=function(e){const t=e;return Ot.defined(t)&&C.is(e.stoppedLocation)},(yt=wt||(wt={})).Type=1,yt.Parameter=2,yt.is=function(e){return 1===e||2===e},(Et=xt||(xt={})).create=function(e){return{value:e}},Et.is=function(e){const t=e;return Ot.objectLiteral(t)&&(void 0===t.tooltip||Ot.string(t.tooltip)||ke.is(t.tooltip))&&(void 0===t.location||w.is(t.location))&&(void 0===t.command||X.is(t.command))},(At=It||(It={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},At.is=function(e){const t=e;return Ot.objectLiteral(t)&&b.is(t.position)&&(Ot.string(t.label)||Ot.typedArray(t.label,xt.is))&&(void 0===t.kind||wt.is(t.kind))&&void 0===t.textEdits||Ot.typedArray(t.textEdits,q.is)&&(void 0===t.tooltip||Ot.string(t.tooltip)||ke.is(t.tooltip))&&(void 0===t.paddingLeft||Ot.boolean(t.paddingLeft))&&(void 0===t.paddingRight||Ot.boolean(t.paddingRight))},(St||(St={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Tt||(Tt={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},(Lt||(Lt={})).create=function(e){return{items:e}},(Mt=Rt||(Rt={})).Invoked=0,Mt.Automatic=1,(Ft||(Ft={})).create=function(e,t){return{range:e,text:t}},(Pt||(Pt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(jt||(jt={})).is=function(e){const t=e;return Ot.objectLiteral(t)&&f.is(t.uri)&&Ot.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),o=e.slice(r);t(i,n),t(o,n);let a=0,s=0,c=0;for(;a{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),o=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],a=e.offsetAt(n.range.start),s=e.offsetAt(n.range.end);if(!(s<=o))throw new Error("Overlapping edit");r=r.substring(0,a)+n.newText+r.substring(s,r.length),o=a}return r}}(Dt||(Dt={}));var Ot,Ut=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return b.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return b.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1{let t,n=e.getLanguageId();n===this._languageId&&(this._listener[e.uri.toString()]=e.onDidChangeContent((()=>{window.clearTimeout(t),t=window.setTimeout((()=>this._doValidate(e.uri,n)),500)})),this._doValidate(e.uri,n))},i=e=>{l.editor.setModelMarkers(e,this._languageId,[]);let t=e.uri.toString(),n=this._listener[t];n&&(n.dispose(),delete this._listener[t])};this._disposables.push(l.editor.onDidCreateModel(r)),this._disposables.push(l.editor.onWillDisposeModel(i)),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{i(e.model),r(e.model)}))),this._disposables.push(n((e=>{l.editor.getModels().forEach((e=>{e.getLanguageId()===this._languageId&&(i(e),r(e))}))}))),this._disposables.push({dispose:()=>{l.editor.getModels().forEach(i);for(let e in this._listener)this._listener[e].dispose()}}),l.editor.getModels().forEach(r)}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables.length=0}_doValidate(e,t){this._worker(e).then((t=>t.doValidation(e.toString()))).then((n=>{const r=n.map((e=>function(e,t){let n="number"===typeof t.code?String(t.code):t.code;return{severity:Bt(t.severity),startLineNumber:t.range.start.line+1,startColumn:t.range.start.character+1,endLineNumber:t.range.end.line+1,endColumn:t.range.end.character+1,message:t.message,code:n,source:t.source}}(0,e)));let i=l.editor.getModel(e);i&&i.getLanguageId()===t&&l.editor.setModelMarkers(i,t,r)})).then(void 0,(e=>{console.error(e)}))}};function Bt(e){switch(e){case O.Error:return l.MarkerSeverity.Error;case O.Warning:return l.MarkerSeverity.Warning;case O.Information:return l.MarkerSeverity.Info;case O.Hint:return l.MarkerSeverity.Hint;default:return l.MarkerSeverity.Info}}var Wt=class{constructor(e,t){this._worker=e,this._triggerCharacters=t}get triggerCharacters(){return this._triggerCharacters}provideCompletionItems(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doComplete(i.toString(),Kt(t)))).then((n=>{if(!n)return;const r=e.getWordUntilPosition(t),i=new l.Range(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn),o=n.items.map((e=>{const t={label:e.label,insertText:e.insertText||e.label,sortText:e.sortText,filterText:e.filterText,documentation:e.documentation,detail:e.detail,command:(n=e.command,n&&"editor.action.triggerSuggest"===n.command?{id:n.command,title:n.title,arguments:n.arguments}:void 0),range:i,kind:zt(e.kind)};var n,r;return e.textEdit&&("undefined"!==typeof(r=e.textEdit).insert&&"undefined"!==typeof r.replace?t.range={insert:Xt(e.textEdit.insert),replace:Xt(e.textEdit.replace)}:t.range=Xt(e.textEdit.range),t.insertText=e.textEdit.newText),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(qt)),e.insertTextFormat===we.Snippet&&(t.insertTextRules=l.languages.CompletionItemInsertTextRule.InsertAsSnippet),t}));return{isIncomplete:n.isIncomplete,suggestions:o}}))}};function Kt(e){if(e)return{character:e.column-1,line:e.lineNumber-1}}function Ht(e){if(e)return{start:{line:e.startLineNumber-1,character:e.startColumn-1},end:{line:e.endLineNumber-1,character:e.endColumn-1}}}function Xt(e){if(e)return new l.Range(e.start.line+1,e.start.character+1,e.end.line+1,e.end.character+1)}function zt(e){const t=l.languages.CompletionItemKind;switch(e){case Ce.Text:return t.Text;case Ce.Method:return t.Method;case Ce.Function:return t.Function;case Ce.Constructor:return t.Constructor;case Ce.Field:return t.Field;case Ce.Variable:return t.Variable;case Ce.Class:return t.Class;case Ce.Interface:return t.Interface;case Ce.Module:return t.Module;case Ce.Property:return t.Property;case Ce.Unit:return t.Unit;case Ce.Value:return t.Value;case Ce.Enum:return t.Enum;case Ce.Keyword:return t.Keyword;case Ce.Snippet:return t.Snippet;case Ce.Color:return t.Color;case Ce.File:return t.File;case Ce.Reference:return t.Reference}return t.Property}function qt(e){if(e)return{range:Xt(e.range),text:e.newText}}var $t=class{constructor(e){this._worker=e}provideHover(e,t,n){let r=e.uri;return this._worker(r).then((e=>e.doHover(r.toString(),Kt(t)))).then((e=>{if(e)return{range:Xt(e.range),contents:Jt(e.contents)}}))}};function Qt(e){return"string"===typeof e?{value:e}:(t=e)&&"object"===typeof t&&"string"===typeof t.kind?"plaintext"===e.kind?{value:e.value.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}:{value:e.value}:{value:"```"+e.language+"\n"+e.value+"\n```\n"};var t}function Jt(e){if(e)return Array.isArray(e)?e.map(Qt):[Qt(e)]}var Gt=class{constructor(e){this._worker=e}provideDocumentHighlights(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDocumentHighlights(r.toString(),Kt(t)))).then((e=>{if(e)return e.map((e=>({range:Xt(e.range),kind:Yt(e.kind)})))}))}};function Yt(e){switch(e){case Ne.Read:return l.languages.DocumentHighlightKind.Read;case Ne.Write:return l.languages.DocumentHighlightKind.Write;case Ne.Text:return l.languages.DocumentHighlightKind.Text}return l.languages.DocumentHighlightKind.Text}var Zt=class{constructor(e){this._worker=e}provideDefinition(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDefinition(r.toString(),Kt(t)))).then((e=>{if(e)return[en(e)]}))}};function en(e){return{uri:l.Uri.parse(e.uri),range:Xt(e.range)}}var tn=class{constructor(e){this._worker=e}provideReferences(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.findReferences(i.toString(),Kt(t)))).then((e=>{if(e)return e.map(en)}))}},nn=class{constructor(e){this._worker=e}provideRenameEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doRename(i.toString(),Kt(t),n))).then((e=>function(e){if(!e||!e.changes)return;let t=[];for(let n in e.changes){const r=l.Uri.parse(n);for(let i of e.changes[n])t.push({resource:r,versionId:void 0,textEdit:{range:Xt(i.range),text:i.newText}})}return{edits:t}}(e)))}};var rn=class{constructor(e){this._worker=e}provideDocumentSymbols(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentSymbols(n.toString()))).then((e=>{if(e)return e.map((e=>"children"in e?on(e):{name:e.name,detail:"",containerName:e.containerName,kind:an(e.kind),range:Xt(e.location.range),selectionRange:Xt(e.location.range),tags:[]}))}))}};function on(e){return{name:e.name,detail:e.detail??"",kind:an(e.kind),range:Xt(e.range),selectionRange:Xt(e.selectionRange),tags:e.tags??[],children:(e.children??[]).map((e=>on(e)))}}function an(e){let t=l.languages.SymbolKind;switch(e){case Ve.File:return t.File;case Ve.Module:return t.Module;case Ve.Namespace:return t.Namespace;case Ve.Package:return t.Package;case Ve.Class:return t.Class;case Ve.Method:return t.Method;case Ve.Property:return t.Property;case Ve.Field:return t.Field;case Ve.Constructor:return t.Constructor;case Ve.Enum:return t.Enum;case Ve.Interface:return t.Interface;case Ve.Function:return t.Function;case Ve.Variable:return t.Variable;case Ve.Constant:return t.Constant;case Ve.String:return t.String;case Ve.Number:return t.Number;case Ve.Boolean:return t.Boolean;case Ve.Array:return t.Array}return t.Function}var sn=class{constructor(e){this._worker=e}provideLinks(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentLinks(n.toString()))).then((e=>{if(e)return{links:e.map((e=>({range:Xt(e.range),url:e.target})))}}))}},cn=class{constructor(e){this._worker=e}provideDocumentFormattingEdits(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.format(r.toString(),null,dn(t)).then((e=>{if(e&&0!==e.length)return e.map(qt)}))))}},un=class{constructor(e){this._worker=e,this.canFormatMultipleRanges=!1}provideDocumentRangeFormattingEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.format(i.toString(),Ht(t),dn(n)).then((e=>{if(e&&0!==e.length)return e.map(qt)}))))}};function dn(e){return{tabSize:e.tabSize,insertSpaces:e.insertSpaces}}var ln=class{constructor(e){this._worker=e}provideDocumentColors(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentColors(n.toString()))).then((e=>{if(e)return e.map((e=>({color:e.color,range:Xt(e.range)})))}))}provideColorPresentations(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getColorPresentations(r.toString(),t.color,Ht(t.range)))).then((e=>{if(e)return e.map((e=>{let t={label:e.label};return e.textEdit&&(t.textEdit=qt(e.textEdit)),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(qt)),t}))}))}},gn=class{constructor(e){this._worker=e}provideFoldingRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getFoldingRanges(r.toString(),t))).then((e=>{if(e)return e.map((e=>{const t={start:e.startLine+1,end:e.endLine+1};return"undefined"!==typeof e.kind&&(t.kind=function(e){switch(e){case M.Comment:return l.languages.FoldingRangeKind.Comment;case M.Imports:return l.languages.FoldingRangeKind.Imports;case M.Region:return l.languages.FoldingRangeKind.Region}return}(e.kind)),t}))}))}};var fn,hn,pn=class{constructor(e){this._worker=e}provideSelectionRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getSelectionRanges(r.toString(),t.map(Kt)))).then((e=>{if(e)return e.map((e=>{const t=[];for(;e;)t.push({range:Xt(e.range)}),e=e.parent;return t}))}))}};function mn(e){return 32===e||9===e}function vn(e){return 10===e||13===e}function bn(e){return e>=48&&e<=57}(hn=fn||(fn={}))[hn.lineFeed=10]="lineFeed",hn[hn.carriageReturn=13]="carriageReturn",hn[hn.space=32]="space",hn[hn._0=48]="_0",hn[hn._1=49]="_1",hn[hn._2=50]="_2",hn[hn._3=51]="_3",hn[hn._4=52]="_4",hn[hn._5=53]="_5",hn[hn._6=54]="_6",hn[hn._7=55]="_7",hn[hn._8=56]="_8",hn[hn._9=57]="_9",hn[hn.a=97]="a",hn[hn.b=98]="b",hn[hn.c=99]="c",hn[hn.d=100]="d",hn[hn.e=101]="e",hn[hn.f=102]="f",hn[hn.g=103]="g",hn[hn.h=104]="h",hn[hn.i=105]="i",hn[hn.j=106]="j",hn[hn.k=107]="k",hn[hn.l=108]="l",hn[hn.m=109]="m",hn[hn.n=110]="n",hn[hn.o=111]="o",hn[hn.p=112]="p",hn[hn.q=113]="q",hn[hn.r=114]="r",hn[hn.s=115]="s",hn[hn.t=116]="t",hn[hn.u=117]="u",hn[hn.v=118]="v",hn[hn.w=119]="w",hn[hn.x=120]="x",hn[hn.y=121]="y",hn[hn.z=122]="z",hn[hn.A=65]="A",hn[hn.B=66]="B",hn[hn.C=67]="C",hn[hn.D=68]="D",hn[hn.E=69]="E",hn[hn.F=70]="F",hn[hn.G=71]="G",hn[hn.H=72]="H",hn[hn.I=73]="I",hn[hn.J=74]="J",hn[hn.K=75]="K",hn[hn.L=76]="L",hn[hn.M=77]="M",hn[hn.N=78]="N",hn[hn.O=79]="O",hn[hn.P=80]="P",hn[hn.Q=81]="Q",hn[hn.R=82]="R",hn[hn.S=83]="S",hn[hn.T=84]="T",hn[hn.U=85]="U",hn[hn.V=86]="V",hn[hn.W=87]="W",hn[hn.X=88]="X",hn[hn.Y=89]="Y",hn[hn.Z=90]="Z",hn[hn.asterisk=42]="asterisk",hn[hn.backslash=92]="backslash",hn[hn.closeBrace=125]="closeBrace",hn[hn.closeBracket=93]="closeBracket",hn[hn.colon=58]="colon",hn[hn.comma=44]="comma",hn[hn.dot=46]="dot",hn[hn.doubleQuote=34]="doubleQuote",hn[hn.minus=45]="minus",hn[hn.openBrace=123]="openBrace",hn[hn.openBracket=91]="openBracket",hn[hn.plus=43]="plus",hn[hn.slash=47]="slash",hn[hn.formFeed=12]="formFeed",hn[hn.tab=9]="tab";new Array(20).fill(0).map(((e,t)=>" ".repeat(t)));var kn,Cn=200;new Array(Cn).fill(0).map(((e,t)=>"\n"+" ".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r"+" ".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r\n"+" ".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\n"+"\t".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r"+"\t".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r\n"+"\t".repeat(t)));(kn||(kn={})).DEFAULT={allowTrailingComma:!1};var _n,wn,yn,xn,En,In,An=function(e,t=!1){const n=e.length;let r=0,i="",o=0,a=16,s=0,c=0,u=0,d=0,l=0;function g(t,n){let i=0,o=0;for(;i=48&&t<=57)o=16*o+t-48;else if(t>=65&&t<=70)o=16*o+t-65+10;else{if(!(t>=97&&t<=102))break;o=16*o+t-97+10}r++,i++}return i=n)return o=n,a=17;let t=e.charCodeAt(r);if(mn(t)){do{r++,i+=String.fromCharCode(t),t=e.charCodeAt(r)}while(mn(t));return a=15}if(vn(t))return r++,i+=String.fromCharCode(t),13===t&&10===e.charCodeAt(r)&&(r++,i+="\n"),s++,u=r,a=14;switch(t){case 123:return r++,a=1;case 125:return r++,a=2;case 91:return r++,a=3;case 93:return r++,a=4;case 58:return r++,a=6;case 44:return r++,a=5;case 34:return r++,i=function(){let t="",i=r;for(;;){if(r>=n){t+=e.substring(i,r),l=2;break}const o=e.charCodeAt(r);if(34===o){t+=e.substring(i,r),r++;break}if(92!==o){if(o>=0&&o<=31){if(vn(o)){t+=e.substring(i,r),l=2;break}l=6}r++}else{if(t+=e.substring(i,r),r++,r>=n){l=2;break}switch(e.charCodeAt(r++)){case 34:t+='"';break;case 92:t+="\\";break;case 47:t+="/";break;case 98:t+="\b";break;case 102:t+="\f";break;case 110:t+="\n";break;case 114:t+="\r";break;case 116:t+="\t";break;case 117:const e=g(4,!0);e>=0?t+=String.fromCharCode(e):l=4;break;default:l=5}i=r}}return t}(),a=10;case 47:const c=r-1;if(47===e.charCodeAt(r+1)){for(r+=2;rr,scan:t?function(){let e;do{e=f()}while(e>=12&&e<=15);return e}:f,getToken:()=>a,getTokenValue:()=>i,getTokenOffset:()=>o,getTokenLength:()=>r-o,getTokenStartLine:()=>c,getTokenStartCharacter:()=>o-d,getTokenError:()=>l}};function Sn(e){return{getInitialState:()=>new Wn(null,null,!1,null),tokenize:(t,n)=>function(e,t,n,r=0){let i=0,o=!1;switch(n.scanError){case 2:t='"'+t,i=1;break;case 1:t="/*"+t,i=2}const a=An(t);let s=n.lastWasColon,c=n.parents;const u={tokens:[],endState:n.clone()};for(;;){let d=r+a.getPosition(),l="";const g=a.scan();if(17===g)break;if(d===r+a.getPosition())throw new Error("Scanner did not advance, next 3 characters are: "+t.substr(a.getPosition(),3));switch(o&&(d-=i),o=i>0,g){case 1:c=Bn.push(c,0),l=Ln,s=!1;break;case 2:c=Bn.pop(c),l=Ln,s=!1;break;case 3:c=Bn.push(c,1),l=Rn,s=!1;break;case 4:c=Bn.pop(c),l=Rn,s=!1;break;case 6:l=Mn,s=!0;break;case 5:l=Fn,s=!1;break;case 8:case 9:l=Pn,s=!1;break;case 7:l=jn,s=!1;break;case 10:const e=c?c.type:0;l=s||1===e?Dn:On,s=!1;break;case 11:l=Nn,s=!1}if(e)switch(g){case 12:l=Vn;break;case 13:l=Un}u.endState=new Wn(n.getStateData(),a.getTokenError(),s,c),u.tokens.push({startIndex:d,scopes:l})}return u}(e,t,n)}}(wn=_n||(_n={}))[wn.None=0]="None",wn[wn.UnexpectedEndOfComment=1]="UnexpectedEndOfComment",wn[wn.UnexpectedEndOfString=2]="UnexpectedEndOfString",wn[wn.UnexpectedEndOfNumber=3]="UnexpectedEndOfNumber",wn[wn.InvalidUnicode=4]="InvalidUnicode",wn[wn.InvalidEscapeCharacter=5]="InvalidEscapeCharacter",wn[wn.InvalidCharacter=6]="InvalidCharacter",(xn=yn||(yn={}))[xn.OpenBraceToken=1]="OpenBraceToken",xn[xn.CloseBraceToken=2]="CloseBraceToken",xn[xn.OpenBracketToken=3]="OpenBracketToken",xn[xn.CloseBracketToken=4]="CloseBracketToken",xn[xn.CommaToken=5]="CommaToken",xn[xn.ColonToken=6]="ColonToken",xn[xn.NullKeyword=7]="NullKeyword",xn[xn.TrueKeyword=8]="TrueKeyword",xn[xn.FalseKeyword=9]="FalseKeyword",xn[xn.StringLiteral=10]="StringLiteral",xn[xn.NumericLiteral=11]="NumericLiteral",xn[xn.LineCommentTrivia=12]="LineCommentTrivia",xn[xn.BlockCommentTrivia=13]="BlockCommentTrivia",xn[xn.LineBreakTrivia=14]="LineBreakTrivia",xn[xn.Trivia=15]="Trivia",xn[xn.Unknown=16]="Unknown",xn[xn.EOF=17]="EOF",(In=En||(En={}))[In.InvalidSymbol=1]="InvalidSymbol",In[In.InvalidNumberFormat=2]="InvalidNumberFormat",In[In.PropertyNameExpected=3]="PropertyNameExpected",In[In.ValueExpected=4]="ValueExpected",In[In.ColonExpected=5]="ColonExpected",In[In.CommaExpected=6]="CommaExpected",In[In.CloseBraceExpected=7]="CloseBraceExpected",In[In.CloseBracketExpected=8]="CloseBracketExpected",In[In.EndOfFileExpected=9]="EndOfFileExpected",In[In.InvalidCommentToken=10]="InvalidCommentToken",In[In.UnexpectedEndOfComment=11]="UnexpectedEndOfComment",In[In.UnexpectedEndOfString=12]="UnexpectedEndOfString",In[In.UnexpectedEndOfNumber=13]="UnexpectedEndOfNumber",In[In.InvalidUnicode=14]="InvalidUnicode",In[In.InvalidEscapeCharacter=15]="InvalidEscapeCharacter",In[In.InvalidCharacter=16]="InvalidCharacter";var Tn,Ln="delimiter.bracket.json",Rn="delimiter.array.json",Mn="delimiter.colon.json",Fn="delimiter.comma.json",Pn="keyword.json",jn="keyword.json",Dn="string.value.json",Nn="number.json",On="string.key.json",Un="comment.block.json",Vn="comment.line.json",Bn=class e{constructor(e,t){this.parent=e,this.type=t}static pop(e){return e?e.parent:null}static push(t,n){return new e(t,n)}static equals(e,t){if(!e&&!t)return!0;if(!e||!t)return!1;for(;e&&t;){if(e===t)return!0;if(e.type!==t.type)return!1;e=e.parent,t=t.parent}return!0}},Wn=class e{constructor(e,t,n,r){this._state=e,this.scanError=t,this.lastWasColon=n,this.parents=r}clone(){return new e(this._state,this.scanError,this.lastWasColon,this.parents)}equals(t){return t===this||!!(t&&t instanceof e)&&(this.scanError===t.scanError&&this.lastWasColon===t.lastWasColon&&Bn.equals(this.parents,t.parents))}getStateData(){return this._state}setStateData(e){this._state=e}};function Kn(){return new Promise(((e,t)=>{if(!Tn)return t("JSON not registered!");e(Tn)}))}var Hn=class extends Vt{constructor(e,t,n){super(e,t,n.onDidChange),this._disposables.push(l.editor.onWillDisposeModel((e=>{this._resetSchema(e.uri)}))),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{this._resetSchema(e.model.uri)})))}_resetSchema(e){this._worker().then((t=>{t.resetSchema(e.toString())}))}};function Xn(e){const t=[],n=[],r=new Nt(e);function i(){const{languageId:t,modeConfiguration:r}=e;qn(n),r.documentFormattingEdits&&n.push(l.languages.registerDocumentFormattingEditProvider(t,new cn(Tn))),r.documentRangeFormattingEdits&&n.push(l.languages.registerDocumentRangeFormattingEditProvider(t,new un(Tn))),r.completionItems&&n.push(l.languages.registerCompletionItemProvider(t,new Wt(Tn,[" ",":",'"']))),r.hovers&&n.push(l.languages.registerHoverProvider(t,new $t(Tn))),r.documentSymbols&&n.push(l.languages.registerDocumentSymbolProvider(t,new rn(Tn))),r.tokens&&n.push(l.languages.setTokensProvider(t,Sn(!0))),r.colors&&n.push(l.languages.registerColorProvider(t,new ln(Tn))),r.foldingRanges&&n.push(l.languages.registerFoldingRangeProvider(t,new gn(Tn))),r.diagnostics&&n.push(new Hn(t,Tn,e)),r.selectionRanges&&n.push(l.languages.registerSelectionRangeProvider(t,new pn(Tn)))}t.push(r),Tn=(...e)=>r.getLanguageServiceWorker(...e),i(),t.push(l.languages.setLanguageConfiguration(e.languageId,$n));let o=e.modeConfiguration;return e.onDidChange((e=>{e.modeConfiguration!==o&&(o=e.modeConfiguration,i())})),t.push(zn(n)),zn(t)}function zn(e){return{dispose:()=>qn(e)}}function qn(e){for(;e.length;)e.pop().dispose()}var $n={wordPattern:/(-?\d*\.\d\w*)|([^\[\{\]\}\:\"\,\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string"]},{open:"[",close:"]",notIn:["string"]},{open:'"',close:'"',notIn:["string"]}]}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/65206.7f46c107.chunk.js b/ydb/core/viewer/monitoring/static/js/65206.7f46c107.chunk.js new file mode 100644 index 000000000000..6a6c37fb5433 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/65206.7f46c107.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[65206],{43455:e=>{function t(e){e.languages.squirrel=e.languages.extend("clike",{comment:[e.languages.clike.comment[0],{pattern:/(^|[^\\:])(?:\/\/|#).*/,lookbehind:!0,greedy:!0}],string:{pattern:/(^|[^\\"'@])(?:@"(?:[^"]|"")*"(?!")|"(?:[^\\\r\n"]|\\.)*")/,lookbehind:!0,greedy:!0},"class-name":{pattern:/(\b(?:class|enum|extends|instanceof)\s+)\w+(?:\.\w+)*/,lookbehind:!0,inside:{punctuation:/\./}},keyword:/\b(?:__FILE__|__LINE__|base|break|case|catch|class|clone|const|constructor|continue|default|delete|else|enum|extends|for|foreach|function|if|in|instanceof|local|null|resume|return|static|switch|this|throw|try|typeof|while|yield)\b/,number:/\b(?:0x[0-9a-fA-F]+|\d+(?:\.(?:\d+|[eE][+-]?\d+))?)\b/,operator:/\+\+|--|<=>|<[-<]|>>>?|&&?|\|\|?|[-+*/%!=<>]=?|[~^]|::?/,punctuation:/[(){}\[\],;.]/}),e.languages.insertBefore("squirrel","string",{char:{pattern:/(^|[^\\"'])'(?:[^\\']|\\(?:[xuU][0-9a-fA-F]{0,8}|[\s\S]))'/,lookbehind:!0,greedy:!0}}),e.languages.insertBefore("squirrel","operator",{"attribute-punctuation":{pattern:/<\/|\/>/,alias:"important"},lambda:{pattern:/@(?=\()/,alias:"operator"}})}e.exports=t,t.displayName="squirrel",t.aliases=[]},65206:(e,t,a)=>{a.d(t,{default:()=>r});var n=a(43455);const r=a.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/65252.2655458e.chunk.js b/ydb/core/viewer/monitoring/static/js/65252.2655458e.chunk.js new file mode 100644 index 000000000000..d63f19a27d38 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/65252.2655458e.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 65252.2655458e.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[65252],{65252:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>h,language:()=>b});var a,r,m=n(80781),l=Object.defineProperty,i=Object.getOwnPropertyDescriptor,o=Object.getOwnPropertyNames,d=Object.prototype.hasOwnProperty,s=(e,t,n,a)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let r of o(t))d.call(e,r)||r===n||l(e,r,{get:()=>t[r],enumerable:!(a=i(t,r))||a.enumerable});return e},c={};s(c,a=m,"default"),r&&s(r,a,"default");var p=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],h={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,comments:{blockComment:["{{!--","--}}"]},brackets:[["\x3c!--","--\x3e"],["<",">"],["{{","}}"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/(\w[\w\d]*)\s*>$/i,action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:c.languages.IndentAction.Indent}}]},b={defaultToken:"",tokenPostfix:"",tokenizer:{root:[[/\{\{!--/,"comment.block.start.handlebars","@commentBlock"],[/\{\{!/,"comment.start.handlebars","@comment"],[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.root"}],[/)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)(script)/,["delimiter.html",{token:"tag.html",next:"@script"}]],[/(<)(style)/,["delimiter.html",{token:"tag.html",next:"@style"}]],[/(<)([:\w]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)(\w+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/]+/,"metatag.content.html"],[/>/,"metatag.html","@pop"]],comment:[[/\}\}/,"comment.end.handlebars","@pop"],[/./,"comment.content.handlebars"]],commentBlock:[[/--\}\}/,"comment.block.end.handlebars","@pop"],[/./,"comment.content.handlebars"]],commentHtml:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.comment"}],[/-->/,"comment.html","@pop"],[/[^-]+/,"comment.content.html"],[/./,"comment.content.html"]],otherTag:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.otherTag"}],[/\/?>/,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.script"}],[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],scriptAfterType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.scriptAfterType"}],[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.scriptAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.scriptWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInEmbeddedState.scriptEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],style:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.style"}],[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],styleAfterType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.styleAfterType"}],[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.styleAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInSimpleState.styleWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/\{\{/,{token:"@rematch",switchTo:"@handlebarsInEmbeddedState.styleEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],handlebarsInSimpleState:[[/\{\{\{?/,"delimiter.handlebars"],[/\}\}\}?/,{token:"delimiter.handlebars",switchTo:"@$S2.$S3"}],{include:"handlebarsRoot"}],handlebarsInEmbeddedState:[[/\{\{\{?/,"delimiter.handlebars"],[/\}\}\}?/,{token:"delimiter.handlebars",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}],{include:"handlebarsRoot"}],handlebarsRoot:[[/"[^"]*"/,"string.handlebars"],[/[#/][^\s}]+/,"keyword.helper.handlebars"],[/else\b/,"keyword.helper.handlebars"],[/[\s]+/],[/[^}]/,"variable.parameter.handlebars"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/654.863ea445.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/65252.2655458e.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/654.863ea445.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/65252.2655458e.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/6528.77d69abb.chunk.js b/ydb/core/viewer/monitoring/static/js/6528.77d69abb.chunk.js new file mode 100644 index 000000000000..053420204e0f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/6528.77d69abb.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6528],{6528:(e,t,n)=>{n.d(t,{default:()=>r});var a=n(83695);const r=n.n(a)()},83695:e=>{function t(e){e.languages.julia={comment:{pattern:/(^|[^\\])(?:#=(?:[^#=]|=(?!#)|#(?!=)|#=(?:[^#=]|=(?!#)|#(?!=))*=#)*=#|#.*)/,lookbehind:!0},regex:{pattern:/r"(?:\\.|[^"\\\r\n])*"[imsx]{0,4}/,greedy:!0},string:{pattern:/"""[\s\S]+?"""|(?:\b\w+)?"(?:\\.|[^"\\\r\n])*"|`(?:[^\\`\r\n]|\\.)*`/,greedy:!0},char:{pattern:/(^|[^\w'])'(?:\\[^\r\n][^'\r\n]*|[^\\\r\n])'/,lookbehind:!0,greedy:!0},keyword:/\b(?:abstract|baremodule|begin|bitstype|break|catch|ccall|const|continue|do|else|elseif|end|export|finally|for|function|global|if|immutable|import|importall|in|let|local|macro|module|print|println|quote|return|struct|try|type|typealias|using|while)\b/,boolean:/\b(?:false|true)\b/,number:/(?:\b(?=\d)|\B(?=\.))(?:0[box])?(?:[\da-f]+(?:_[\da-f]+)*(?:\.(?:\d+(?:_\d+)*)?)?|\.\d+(?:_\d+)*)(?:[efp][+-]?\d+(?:_\d+)*)?j?/i,operator:/&&|\|\||[-+*^%\xf7\u22bb&$\\]=?|\/[\/=]?|!=?=?|\|[=>]?|<(?:<=?|[=:|])?|>(?:=|>>?=?)?|==?=?|[~\u2260\u2264\u2265'\u221a\u221b]/,punctuation:/::?|[{}[\]();,.?]/,constant:/\b(?:(?:Inf|NaN)(?:16|32|64)?|im|pi)\b|[\u03c0\u212f]/}}e.exports=t,t.displayName="julia",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/654.863ea445.chunk.js b/ydb/core/viewer/monitoring/static/js/654.863ea445.chunk.js deleted file mode 100644 index 23af2764ea95..000000000000 --- a/ydb/core/viewer/monitoring/static/js/654.863ea445.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 654.863ea445.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[654],{20654:(e,s,o)=>{o.r(s),o.d(s,{conf:()=>t,language:()=>n});var t={comments:{lineComment:"REM"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],surroundingPairs:[{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],folding:{markers:{start:new RegExp("^\\s*(::\\s*|REM\\s+)#region"),end:new RegExp("^\\s*(::\\s*|REM\\s+)#endregion")}}},n={defaultToken:"",ignoreCase:!0,tokenPostfix:".bat",brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:/call|defined|echo|errorlevel|exist|for|goto|if|pause|set|shift|start|title|not|pushd|popd/,symbols:/[=>{n.r(t),n.d(t,{conf:()=>u,language:()=>b});var i,r,o=n(80781),a=Object.defineProperty,d=Object.getOwnPropertyDescriptor,s=Object.getOwnPropertyNames,p=Object.prototype.hasOwnProperty,m=(e,t,n,i)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let r of s(t))p.call(e,r)||r===n||a(e,r,{get:()=>t[r],enumerable:!(i=d(t,r))||i.enumerable});return e},l={};m(l,i=o,"default"),r&&m(r,i,"default");var c=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],u={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,comments:{blockComment:["\x3c!--","--\x3e"]},brackets:[["\x3c!--","--\x3e"],["<",">"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${c.join("|")}))([_:\\w][_:\\w-.\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/([_:\w][_:\w-.\d]*)\s*>$/i,action:{indentAction:l.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${c.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:l.languages.IndentAction.Indent}}],folding:{markers:{start:new RegExp("^\\s*\x3c!--\\s*#region\\b.*--\x3e"),end:new RegExp("^\\s*\x3c!--\\s*#endregion\\b.*--\x3e")}}},b={defaultToken:"",tokenPostfix:".html",ignoreCase:!0,tokenizer:{root:[[/)/,["delimiter","tag","","delimiter"]],[/(<)(script)/,["delimiter",{token:"tag",next:"@script"}]],[/(<)(style)/,["delimiter",{token:"tag",next:"@style"}]],[/(<)((?:[\w\-]+:)?[\w\-]+)/,["delimiter",{token:"tag",next:"@otherTag"}]],[/(<\/)((?:[\w\-]+:)?[\w\-]+)/,["delimiter",{token:"tag",next:"@otherTag"}]],[/]+/,"metatag.content"],[/>/,"metatag","@pop"]],comment:[[/-->/,"comment","@pop"],[/[^-]+/,"comment.content"],[/./,"comment.content"]],otherTag:[[/\/?>/,"delimiter","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter",next:"@scriptEmbedded",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter","tag",{token:"delimiter",next:"@pop"}]]],scriptAfterType:[[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter",next:"@scriptEmbedded",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/"module"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.text/javascript"}],[/'module'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.text/javascript"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter",next:"@scriptEmbedded",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/>/,{token:"delimiter",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}],[/[^<]+/,""]],style:[[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter",next:"@styleEmbedded",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter","tag",{token:"delimiter",next:"@pop"}]]],styleAfterType:[[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter",next:"@styleEmbedded",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter",next:"@styleEmbedded",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/>/,{token:"delimiter",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}],[/[^<]+/,""]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/65579.1ec2325b.chunk.js b/ydb/core/viewer/monitoring/static/js/65579.1ec2325b.chunk.js new file mode 100644 index 000000000000..1686edd1fcff --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/65579.1ec2325b.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[65579],{65579:function(_,e,a){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var a=e(_),t={name:"tzl",weekdays:"S\xfaladi_L\xfane\xe7i_Maitzi_M\xe1rcuri_Xh\xfaadi_Vi\xe9ner\xe7i_S\xe1turi".split("_"),months:"Januar_Fevraglh_Mar\xe7_Avr\xefu_Mai_G\xfcn_Julia_Guscht_Setemvar_Listop\xe4ts_Noemvar_Zecemvar".split("_"),weekStart:1,weekdaysShort:"S\xfal_L\xfan_Mai_M\xe1r_Xh\xfa_Vi\xe9_S\xe1t".split("_"),monthsShort:"Jan_Fev_Mar_Avr_Mai_G\xfcn_Jul_Gus_Set_Lis_Noe_Zec".split("_"),weekdaysMin:"S\xfa_L\xfa_Ma_M\xe1_Xh_Vi_S\xe1".split("_"),ordinal:function(_){return _},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD.MM.YYYY",LL:"D. MMMM [dallas] YYYY",LLL:"D. MMMM [dallas] YYYY HH.mm",LLLL:"dddd, [li] D. MMMM [dallas] YYYY HH.mm"}};return a.default.locale(t,null,!0),t}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/65633.b6bc2f47.chunk.js b/ydb/core/viewer/monitoring/static/js/65633.b6bc2f47.chunk.js new file mode 100644 index 000000000000..3842fa9cf040 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/65633.b6bc2f47.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[65633],{4308:e=>{function n(e){e.languages.reason=e.languages.extend("clike",{string:{pattern:/"(?:\\(?:\r\n|[\s\S])|[^\\\r\n"])*"/,greedy:!0},"class-name":/\b[A-Z]\w*/,keyword:/\b(?:and|as|assert|begin|class|constraint|do|done|downto|else|end|exception|external|for|fun|function|functor|if|in|include|inherit|initializer|lazy|let|method|module|mutable|new|nonrec|object|of|open|or|private|rec|sig|struct|switch|then|to|try|type|val|virtual|when|while|with)\b/,operator:/\.{3}|:[:=]|\|>|->|=(?:==?|>)?|<=?|>=?|[|^?'#!~`]|[+\-*\/]\.?|\b(?:asr|land|lor|lsl|lsr|lxor|mod)\b/}),e.languages.insertBefore("reason","class-name",{char:{pattern:/'(?:\\x[\da-f]{2}|\\o[0-3][0-7][0-7]|\\\d{3}|\\.|[^'\\\r\n])'/,greedy:!0},constructor:/\b[A-Z]\w*\b(?!\s*\.)/,label:{pattern:/\b[a-z]\w*(?=::)/,alias:"symbol"}}),delete e.languages.reason.function}e.exports=n,n.displayName="reason",n.aliases=[]},65633:(e,n,a)=>{a.d(n,{default:()=>r});var t=a(4308);const r=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/65915.b32b0224.chunk.js b/ydb/core/viewer/monitoring/static/js/65915.b32b0224.chunk.js new file mode 100644 index 000000000000..611602b2c3b1 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/65915.b32b0224.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[65915],{156:(e,t,n)=>{n.d(t,{k_:()=>f,QQ:()=>b,b0:()=>y,OH:()=>S,fj:()=>h,Ep:()=>N});var s=n(59284),o=n(24600),a=n(7435),r=n(16439),i=n(90182);const l=3,d=2,u=120,c=10,m=1,p=10;function h(){const[e,t]=s.useState(void 0),[n,o]=s.useState(void 0);return{handleDataFetched:s.useCallback((n=>{if(null!==n&&void 0!==n&&n.columnsSettings&&!e){const{maxSlotsPerDisk:e,maxDisksPerNode:s}=n.columnsSettings,a=e||m,r=s||m,i=Math.max(a*l+(a-1)*d,u),h=r*i+(r-1)*c+2*p;t(i),o(h)}}),[e]),columnsSettings:s.useMemo((()=>({pDiskWidth:e||u,pDiskContainerWidth:n})),[n,e])}}const g=(0,r.H)(["success","warning","danger"],1,2),v={"block-4-2":(0,r.H)(["success","warning","danger"],1,2),"mirror-3-dc":(0,r.H)(["success","warning","danger"],1,3)},f=e=>{var t;return(void 0!==(t=e.ErasureSpecies)&&t in v?v[e.ErasureSpecies]:g)(e.Degraded)};function S(e,t){var n;let s=!0;return(0,a.f8)(null===(n=e.VDiskId)||void 0===n?void 0:n.GroupID)&&null!==t&&void 0!==t&&t.groupId&&(s&&=String(e.VDiskId.GroupID)===t.groupId),(0,a.f8)(e.NodeId)&&null!==t&&void 0!==t&&t.nodeId&&(s&&=String(e.NodeId)===t.nodeId),(0,a.f8)(e.PDiskId)&&null!==t&&void 0!==t&&t.pDiskId&&(s&&=String(e.PDiskId)===t.pDiskId),(0,a.f8)(e.VDiskSlotId)&&null!==t&&void 0!==t&&t.vDiskSlotId&&(s&&=String(e.VDiskSlotId)===t.vDiskSlotId),s}const k=10;function y(e){return(0,a.f8)(null===e||void 0===e?void 0:e.nodeId)||(0,a.f8)(null===e||void 0===e?void 0:e.pDiskId)||(0,a.f8)(null===e||void 0===e?void 0:e.vDiskSlotId)?1:k}function b(e){return(0,a.f8)(null===e||void 0===e?void 0:e.groupId)||(0,a.f8)(null===e||void 0===e?void 0:e.vDiskSlotId)?1:k}function N(e=[],t){const n=(0,i.N4)(o.K);return s.useMemo((()=>{const s=[];return function(e){return"mirror-3-dc"===e||"mirror-3of4"===e}(t)?(e.forEach(((t,o)=>{var a,r,i;(null===n||void 0===n||null===(a=n.get(Number(null===t||void 0===t?void 0:t.NodeId)))||void 0===a?void 0:a.DC)!==(null===n||void 0===n||null===(r=n.get(Number(null===(i=e[o+1])||void 0===i?void 0:i.NodeId)))||void 0===r?void 0:r.DC)&&s.push(o)})),s):s}),[t,e,n])}},5707:(e,t,n)=>{n.d(t,{A$:()=>r,Km:()=>i,Yh:()=>l,aW:()=>a,iZ:()=>u,qs:()=>d});var s=n(94025),o=n(67375);const a={Grey:0,Green:1,Blue:2,Yellow:3,Orange:4,Red:5},r=Object.entries(a).reduce(((e,[t,n])=>({...e,[n]:t})),{}),i=a.Grey,l=r[i],d={[o.W.OK]:a.Green,[o.W.Initial]:a.Yellow,[o.W.SyncGuidRecovery]:a.Yellow,[o.W.LocalRecoveryError]:a.Red,[o.W.SyncGuidRecoveryError]:a.Red,[o.W.PDiskError]:a.Red},u={[s.t.Normal]:a.Green,[s.t.Initial]:a.Yellow,[s.t.InitialFormatRead]:a.Yellow,[s.t.InitialSysLogRead]:a.Yellow,[s.t.InitialCommonLogRead]:a.Yellow,[s.t.InitialFormatReadError]:a.Red,[s.t.InitialSysLogReadError]:a.Red,[s.t.InitialSysLogParseError]:a.Red,[s.t.InitialCommonLogReadError]:a.Red,[s.t.InitialCommonLogParseError]:a.Red,[s.t.CommonLoggerInitError]:a.Red,[s.t.OpenFileError]:a.Red,[s.t.ChunkQuotaError]:a.Red,[s.t.DeviceIoError]:a.Red,[s.t.Stopped]:a.Red}},7187:(e,t,n)=>{n.d(t,{H7:()=>c,NJ:()=>i,SW:()=>d,XY:()=>u,gh:()=>p,r$:()=>m});var s=n(7435),o=n(54090),a=n(16439),r=n(5707);function i(e){return"VDiskId"in e}const l=(0,a.H)([o.m.Green,o.m.Yellow,o.m.Red]),d=e=>(0,s.f8)(e)?c(l(e)):0;function u(e){return void 0===e?r.Yh:r.A$[e]||r.Yh}function c(e){return e?r.aW[e]:0}function m({nodeId:e,pDiskId:t}){if((0,s.f8)(e)&&(0,s.f8)(t))return`${e}-${t}`}function p(e,t,n){return[e,t,n].join("-")}},8809:(e,t,n)=>{n.d(t,{y:()=>j});var s=n(77506),o=n(88226),a=n(13096),r=n(44294),i=n(59284),l=n(87184),d=n(47665),u=n(24600),c=n(54090),m=n(7435),p=n(76086),h=n(31684),g=n(7187),v=n(90182),f=n(12888),S=n(41650),k=n(60073),y=n(25196),b=n(96927),N=n(92459);function D(e){let t;return(0,m.f8)(e.VDiskSlotId)&&(0,m.f8)(e.PDiskId)&&(0,m.f8)(e.NodeId)?t=(0,N.yX)({vDiskSlotId:e.VDiskSlotId,pDiskId:e.PDiskId,nodeId:e.NodeId}):(0,m.f8)(e.StringifiedId)&&(t=(0,N.yX)({vDiskId:e.StringifiedId,pDiskId:e.PDiskId,nodeId:e.NodeId})),t}var x=n(39110),w=n(60712);const I=(0,s.cn)("vdisk-storage-popup"),C=({data:e})=>{const t=(0,g.NJ)(e),n=(0,f.X)(),s=i.useMemo((()=>t?((e,t)=>{var n,s,o,a;const{NodeId:r,PDiskId:i,VDiskSlotId:d,StringifiedId:u,VDiskState:p,SatisfactionRank:g,DiskSpace:v,FrontQueues:f,Replicated:k,UnsyncedVDisks:b,AllocatedSize:N,ReadThroughput:I,WriteThroughput:C,StoragePoolName:P}=e,j=[{label:"VDisk",value:u},{label:"State",value:null!==p&&void 0!==p?p:"not available"}];var E,A;if(P&&j.push({label:"StoragePool",value:P}),g&&(null===(n=g.FreshRank)||void 0===n?void 0:n.Flag)!==c.m.Green&&j.push({label:"Fresh",value:null===(E=g.FreshRank)||void 0===E?void 0:E.Flag}),g&&(null===(s=g.LevelRank)||void 0===s?void 0:s.Flag)!==c.m.Green&&j.push({label:"Level",value:null===(A=g.LevelRank)||void 0===A?void 0:A.Flag}),g&&null!==(o=g.FreshRank)&&void 0!==o&&o.RankPercent&&j.push({label:"Fresh",value:g.FreshRank.RankPercent}),g&&null!==(a=g.LevelRank)&&void 0!==a&&a.RankPercent&&j.push({label:"Level",value:g.LevelRank.RankPercent}),v&&v!==c.m.Green&&j.push({label:"Space",value:v}),f&&f!==c.m.Green&&j.push({label:"FrontQueues",value:f}),!1===k&&j.push({label:"Replicated",value:"NO"}),b&&j.push({label:"UnsyncVDisks",value:b}),Number(N)&&j.push({label:"Allocated",value:(0,S.wb)(N)}),Number(I)&&j.push({label:"Read",value:(0,S.O4)(I)}),Number(C)&&j.push({label:"Write",value:(0,S.O4)(C)}),t&&(0,m.f8)(r)&&(0,m.f8)(i)&&((0,m.f8)(d)||(0,m.f8)(u))){const e=(0,m.f8)(d)?(0,h.Wg)({nodeId:r,pDiskId:i,vDiskSlotId:d}):void 0,t=D({VDiskSlotId:d,PDiskId:i,NodeId:r,StringifiedId:u});t&&j.push({label:"Links",value:(0,w.jsxs)(l.s,{wrap:"wrap",gap:2,children:[(0,w.jsx)(y.K,{title:(0,x.r)("vdisk-page"),url:t,external:!1},t),e?(0,w.jsx)(y.K,{title:(0,x.r)("developer-ui"),url:e}):null]})})}return j})(e,n):((e,t)=>{const{NodeId:n,PDiskId:s,VSlotId:o,StoragePoolName:a}=e,r=[{label:"State",value:"not available"}];if(a&&r.push({label:"StoragePool",value:a}),r.push({label:"NodeId",value:null!==n&&void 0!==n?n:p.Pd},{label:"PDiskId",value:null!==s&&void 0!==s?s:p.Pd},{label:"VSlotId",value:null!==o&&void 0!==o?o:p.Pd}),t&&(0,m.f8)(n)&&(0,m.f8)(s)&&(0,m.f8)(o)){const e=(0,h.Wg)({nodeId:n,pDiskId:s,vDiskSlotId:o});r.push({label:"Links",value:(0,w.jsx)(y.K,{title:"Developer UI",url:e})})}return r})(e,n)),[e,t,n]),o=(0,v.N4)(u.K),a=(0,m.f8)(e.NodeId)?null===o||void 0===o?void 0:o.get(e.NodeId):void 0,N=i.useMemo((()=>t&&e.PDisk&&(0,b.f)(e.PDisk,a,n)),[e,a,t,n]),C=[];if("Donors"in e&&e.Donors){const t=e.Donors;for(const e of t)C.push({label:"VDisk",value:(0,w.jsx)(r.E,{to:D(e),children:e.StringifiedId})})}return(0,w.jsxs)("div",{className:I(),children:[e.DonorMode&&(0,w.jsx)(d.J,{className:I("donor-label"),children:"Donor"}),(0,w.jsx)(k.z_,{title:"VDisk",info:s,size:"s"}),N&&(0,w.jsx)(k.z_,{title:"PDisk",info:N,size:"s"}),C.length>0&&(0,w.jsx)(k.z_,{title:"Donors",info:C,size:"s"})]})},P=(0,s.cn)("ydb-vdisk-component"),j=({data:e={},compact:t,inactive:n,showPopup:s,onShowPopup:i,onHidePopup:l,progressBarClassName:d,delayClose:u,delayOpen:c})=>{const m=D(e);return(0,w.jsx)(a.P,{showPopup:s,onShowPopup:i,onHidePopup:l,renderPopupContent:()=>(0,w.jsx)(C,{data:e}),offset:[0,5],delayClose:u,delayOpen:c,children:(0,w.jsx)("div",{className:P(),children:(0,w.jsx)(r.E,{to:m,className:P("content"),children:(0,w.jsx)(o.V,{diskAllocatedPercent:e.AllocatedPercent,severity:e.Severity,compact:t,inactive:n,className:d})})})})}},10174:(e,t,n)=>{n.d(t,{S:()=>r});var s=n(21334),o=n(16029),a=n(11905);const r=s.F.injectEndpoints({endpoints:e=>({getStorageNodesInfo:e.query({queryFn:async(e,{signal:t})=>{try{const n=await window.api.viewer.getNodes({storage:!0,type:"static",...e},{signal:t});return{data:(0,a.rz)(n)}}catch(n){return{error:n}}},providesTags:["All","StorageData"]}),getStorageGroupsInfo:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await(0,o.t)(e,{signal:t})}}catch(n){return{error:n}}},providesTags:["All","StorageData"]})}),overrideExisting:"throw"})},10576:(e,t,n)=>{n.d(t,{E:()=>g});var s=n(59284),o=n(88226),a=n(13096),r=n(44294),i=n(96927),l=n(8809),d=n(92459),u=n(7435),c=n(77506),m=n(156),p=n(60712);const h=(0,c.cn)("pdisk-storage"),g=({data:e={},vDisks:t,showPopup:n,onShowPopup:c,onHidePopup:g,className:v,progressBarClassName:f,viewContext:S,width:k})=>{const{NodeId:y,PDiskId:b}=e,N=(0,u.f8)(y)&&(0,u.f8)(b),D=s.useRef(null);let x;return N&&(x=(0,d.Ck)(b,y)),(0,p.jsxs)("div",{className:h(null,v),ref:D,style:{width:k},children:[null!==t&&void 0!==t&&t.length?(0,p.jsx)("div",{className:h("vdisks"),children:t.map((e=>(0,p.jsx)("div",{className:h("vdisks-item"),style:{flexGrow:Number(e.AllocatedSize)||1},children:(0,p.jsx)(l.y,{data:e,inactive:!(0,m.OH)(e,S),compact:!0,delayClose:200,delayOpen:200})},e.StringifiedId)))}):null,(0,p.jsx)(a.P,{showPopup:n,offset:[0,5],anchorRef:D,onShowPopup:c,onHidePopup:g,renderPopupContent:()=>(0,p.jsx)(i.O,{data:e}),delayClose:200,children:(0,p.jsxs)(r.E,{to:x,className:h("content"),children:[(0,p.jsx)(o.V,{diskAllocatedPercent:e.AllocatedPercent,severity:e.Severity,className:f}),(0,p.jsx)("div",{className:h("media-type"),children:e.Type})]})})]})}},10662:(e,t,n)=>{n.d(t,{i:()=>r});var s=n(28664),o=n(59284);var a=n(60712);const r=({onUpdate:e,value:t="",debounce:n=200,...r})=>{const[i,l]=function({value:e,onUpdate:t,debounce:n=200}){const[s,a]=o.useState(e),r=o.useRef();return o.useEffect((()=>{a((t=>t!==e?e:t))}),[e]),[s,e=>{a(e),window.clearTimeout(r.current),r.current=window.setTimeout((()=>{null===t||void 0===t||t(e)}),n)}]}({value:t,onUpdate:e,debounce:n});return(0,a.jsx)(s.k,{value:i,onUpdate:l,...r})}},10731:(e,t,n)=>{n.d(t,{U:()=>c});var s=n(84476),o=n(7889),a=n(78524),r=n(48372);const i=JSON.parse('{"default_message":"Everything is fine!","default_button_label":"Show All"}'),l=JSON.parse('{"default_message":"\u0412\u0441\u0451 \u0432 \u043f\u043e\u0440\u044f\u0434\u043a\u0435!","default_button_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435"}'),d=(0,r.g4)("ydb-storage-empty-filter",{ru:l,en:i});var u=n(60712);const c=({title:e,message:t=d("default_message"),showAll:n=d("default_button_label"),onShowAll:r,image:i=(0,u.jsx)(a.v,{name:"thumbsUp"})})=>(0,u.jsx)(o.p,{image:i,position:"left",title:e,description:t,actions:r&&[(0,u.jsx)(s.$,{onClick:r,children:n},"show-all")]})},11905:(e,t,n)=>{n.d(t,{Rv:()=>y,rz:()=>S,Qi:()=>k});var s=n(94025),o=n(67375),a=n(7187),r=n(27295),i=n(78034);var l=n(73891),d=n(56839),u=n(51930),c=n(64036),m=n(78461);function p(e={}){var t,n,s,o;const{Whiteboard:i={},PDisk:l,...h}=e,g={...i,...h,VDiskId:i.VDiskId},v=function(e={}){var t,n,s;const{Whiteboard:o,...i}=e,l={...o,...i,PDiskId:null===o||void 0===o?void 0:o.PDiskId};if(void 0===l.PDiskId&&i.PDiskId){const e=Number(i.PDiskId.split("-")[1]);isNaN(e)||(l.PDiskId=e)}const d=i.PDiskId||(0,a.r$)({nodeId:l.NodeId,pDiskId:l.PDiskId}),{AllocatedPercent:c,AllocatedSize:p,AvailableSize:h,TotalSize:g}=(0,r.hK)({AvailableSize:l.AvailableSize,TotalSize:l.TotalSize}),v=null!==(t=null===(n=i.Type)||void 0===n?void 0:n.toUpperCase())&&void 0!==t?t:(0,m.Y)(null===o||void 0===o?void 0:o.Category),f=(0,u.d)({State:null===o||void 0===o?void 0:o.State,AllocatedPercent:c}),S=null!==(s=i.SlotSize)&&void 0!==s?s:null===o||void 0===o?void 0:o.EnforcedDynamicSlotSize;return{...l,StringifiedId:d,AllocatedPercent:c,AllocatedSize:p,AvailableSize:h,TotalSize:g,Type:v,Severity:f,SlotSize:S}}({...l,NodeId:g.NodeId}),f=null!==(t=null===v||void 0===v?void 0:v.PDiskId)&&void 0!==t?t:null===i||void 0===i?void 0:i.PDiskId,S=null!==(n=h.VDiskId)&&void 0!==n?n:(0,d.U9)(i.VDiskId),k=(0,c.b)(g),y=(0,r.LW)({AvailableSize:null!==(s=g.AvailableSize)&&void 0!==s?s:null===l||void 0===l?void 0:l.AvailableSize,AllocatedSize:g.AllocatedSize}),b=null===(o=h.Donors)||void 0===o?void 0:o.map((e=>p({...e,Whiteboard:{...e.Whiteboard,DonorMode:!0}})));return{...g,...y,PDisk:v,Donors:b,PDiskId:f,StringifiedId:S,Severity:k}}function h(e){const{DiskSpace:t,VDisks:n=[]}=e;return t||(0,a.XY)(Math.max(...n.map((e=>(0,a.H7)(e.DiskSpace)))))}const g=(e,t)=>{var n;const s=(0,r.WT)(e);return{...s,StoragePoolName:t,Donors:null===s||void 0===s||null===(n=s.Donors)||void 0===n?void 0:n.map((e=>({...e,StoragePoolName:t})))}},v=(e,t)=>{var n;let a,i=0,l=0,d=0,u=0,c=0;const{Name:m,MediaType:p}=t;if(e.VDisks)for(const h of e.VDisks){const{Replicated:e,VDiskState:t,AvailableSize:n,AllocatedSize:m,PDisk:p,ReadThroughput:g,WriteThroughput:v}=h,{Type:f,State:S,AvailableSize:k}=(0,r.or)(p);!1!==e&&S===s.t.Normal&&t===o.W.OK||(i+=1);const y=Number(null!==n&&void 0!==n?n:k)||0,b=Number(m)||0;l+=b,d+=y+b,u+=Number(g)||0,c+=Number(v)||0,a=!f||f!==a&&a?"Mixed":f}const v=null===(n=e.VDisks)||void 0===n?void 0:n.map((e=>g(e,m))),f=d?((e,t=1)=>{const n=e.Limit?100*e.Used/e.Limit:0;return Math.floor(n/t)*t})({Used:l,Limit:d},5):void 0,S=h(e);return{...e,GroupGeneration:e.GroupGeneration?String(e.GroupGeneration):void 0,GroupId:e.GroupID,Overall:e.Overall,VDisks:v,Usage:f,Read:u,Write:c,PoolName:m,Used:l,Limit:d,Degraded:i,MediaType:p||a||void 0,DiskSpace:S}},f=e=>{const{VDisks:t=[],PoolName:n,Usage:s=0,Read:o=0,Write:a=0,Used:r=0,Limit:i=0,Degraded:l=0,Kind:d,MediaType:u,GroupID:c,Overall:m,GroupGeneration:p}=e,v=t.map((e=>g(e,n))),f=100*Number(s),S=h(e);return{...e,PoolName:n,GroupId:c,MediaType:u||d,VDisks:v,Usage:f,Overall:m,GroupGeneration:p?String(p):void 0,Read:Number(o),Write:Number(a),Used:Number(r),Limit:Number(i),Degraded:Number(l),DiskSpace:S}},S=e=>{const{Nodes:t,TotalNodes:n,FoundNodes:o,NodeGroups:a,MaximumSlotsPerDisk:l,MaximumDisksPerNode:d}=e,u=null===a||void 0===a?void 0:a.map((({GroupName:e,NodeCount:t})=>{if(e&&t)return{name:e,count:Number(t)}})).filter((e=>Boolean(e))),c=((e,t)=>{if(t&&!isNaN(Number(t)))return Number(t);const n=(e||[]).flatMap((e=>{const t=e.PDisks||[],n=e.VDisks||[];return t.map((e=>n.filter((t=>t.PDiskId===e.PDiskId)).length||0))}));return Math.max(1,...n)})(t,l),m=((e,t)=>{if(t&&!isNaN(Number(t)))return Number(t);const n=(e||[]).map((e=>{var t;return(null===(t=e.PDisks)||void 0===t?void 0:t.length)||0}));return Math.max(1,...n)})(t,d),p=null===t||void 0===t?void 0:t.map((e=>((e,t,n)=>{var o,a,l;const d=(null===(o=e.PDisks)||void 0===o?void 0:o.filter((e=>e.State!==s.t.Normal)).length)||0,u=null===(a=e.PDisks)||void 0===a?void 0:a.map((t=>({...(0,r.or)(t),NodeId:e.NodeId}))),c=null===(l=e.VDisks)||void 0===l?void 0:l.map((t=>({...(0,r.WT)(t),NodeId:e.NodeId})));return{...(0,i.q1)(e.SystemState),NodeId:e.NodeId,DiskSpaceUsage:e.DiskSpaceUsage,PDisks:u,VDisks:c,Missing:d,MaximumSlotsPerDisk:t,MaximumDisksPerNode:n}})(e,c,m)));return{nodes:p,total:Number(n)||(null===p||void 0===p?void 0:p.length),found:Number(o),tableGroups:u,columnsSettings:{maxSlotsPerDisk:c,maxDisksPerNode:m}}},k=e=>{const{StoragePools:t,StorageGroups:n,TotalGroups:s,FoundGroups:o}=e,a=((e,t)=>{let n=[];return e?n=e.map(f):null===t||void 0===t||t.forEach((e=>{var t;null===(t=e.Groups)||void 0===t||t.forEach((t=>{n.push(v(t,e))}))})),n})(n,t);return{groups:a,total:Number(s)||a.length,found:Number(o)}};function y(e){const{FoundGroups:t,TotalGroups:n,StorageGroups:s=[],StorageGroupGroups:o}=e,a=s.map((e=>{const{Usage:t,DiskSpaceUsage:n,Read:s,Write:o,Used:a,Limit:r,MissingDisks:i,VDisks:d=[],Overall:u,LatencyPutTabletLog:c,LatencyPutUserData:m,LatencyGetFast:g}=e,v=d.map(p),f=h(e);return{...e,Usage:t,DiskSpaceUsage:n,Read:Number(s),Write:Number(o),Used:Number(a),Limit:Number(r),LatencyPutTabletLogMs:(0,l.Jc)(c),LatencyPutUserDataMs:(0,l.Jc)(m),LatencyGetFastMs:(0,l.Jc)(g),Degraded:Number(i),Overall:u,VDisks:v,DiskSpace:f}})),r=null===o||void 0===o?void 0:o.map((({GroupName:e,GroupCount:t})=>{if(e&&t)return{name:e,count:Number(t)}})).filter((e=>Boolean(e)));return{groups:a,total:Number(n)||a.length,found:Number(t),tableGroups:r}}},13096:(e,t,n)=>{n.d(t,{P:()=>u});var s=n(59284),o=n(39238),a=n(43781),r=n.n(a),i=n(77506),l=n(60712);const d=(0,i.cn)("hover-popup"),u=({children:e,renderPopupContent:t,showPopup:n,offset:a,anchorRef:i,onShowPopup:u,onHidePopup:c,placement:m=["top","bottom"],contentClassName:p,delayClose:h=100,delayOpen:g=100})=>{const[v,f]=s.useState(!1),S=s.useRef(null),k=s.useMemo((()=>r()((()=>{f(!0),null===u||void 0===u||u()}),g)),[u,g]),y=s.useCallback((()=>{f(!1),null===c||void 0===c||c()}),[c]),b=s.useMemo((()=>r()(y,h)),[y,h]),N=k,[D,x]=s.useState(!1),[w,I]=s.useState(!1),C=s.useCallback((()=>{x(!0)}),[]),P=s.useCallback((()=>{x(!1)}),[]),j=s.useCallback((()=>{I(!0)}),[]),E=s.useCallback((()=>{I(!1)}),[]),A=s.useCallback((()=>{I(!1),x(!1),y()}),[y]),T=v||n||D||w;return(0,l.jsxs)(s.Fragment,{children:[(0,l.jsx)("span",{ref:S,onMouseEnter:N,onMouseLeave:()=>{k.cancel(),b()},children:e}),T?(0,l.jsx)(o.z,{contentClassName:d(null,p),anchorRef:i||S,onMouseEnter:C,onMouseLeave:P,onEscapeKeyDown:A,onBlur:E,placement:m,hasArrow:!0,open:!0,offset:a||[0,12],children:(0,l.jsx)("div",{onContextMenu:j,children:t()})}):null]})}},15132:(e,t,n)=>{n.d(t,{O:()=>m});var s=n(38501),o=n(77506),a=n(56839),r=n(35736),i=n(41650),l=n(60712);const d=(0,o.cn)("progress-viewer"),u=e=>(0,a.ZV)((0,a.CR)(Number(e),2)),c=(e,t)=>[u(e),u(t)];function m({value:e,capacity:t,formatValues:n=c,percents:o,className:a,size:u="xs",colorizeProgress:m,inverseColorize:p,warningThreshold:h,dangerThreshold:g,hideCapacity:v}){const f=(0,s.D)();let S=Math.floor(parseFloat(String(e))/parseFloat(String(t))*100)||0;S=S>100?100:S;let k=e,y=t,b="/";o?(k=S+"%",y="",b=""):n&&([k,y]=n(Number(e),Number(t)));const N=(0,r.w)({fillWidth:S,warningThreshold:h,dangerThreshold:g,colorizeProgress:m,inverseColorize:p});m&&!(0,i.kf)(t)&&(S=100);const D={width:S+"%"};return(0,i.kf)(e)?(0,l.jsxs)("div",{className:d({size:u,theme:f,status:N},a),children:[(0,l.jsx)("div",{className:d("line"),style:D}),(0,l.jsx)("span",{className:d("text"),children:(0,i.kf)(t)&&!v?`${k} ${b} ${y}`:k})]}):(0,l.jsx)("div",{className:`${d({size:u})} ${a} error`,children:"no data"})}},16029:(e,t,n)=>{n.d(t,{t:()=>o});var s=n(11905);async function o({version:e="v2",shouldUseGroupsHandler:t,...n},o){if(t&&"v1"!==e){const e=await window.api.storage.getStorageGroups({...n},o);return(0,s.Rv)(e)}{const t=await window.api.viewer.getStorageInfo({version:e,...n},o);return(0,s.Qi)(t)}}},19228:(e,t,n)=>{n.d(t,{Q:()=>l});var s=n(89169),o=n(77506),a=n(66781),r=n(60712);const i=(0,o.cn)("table-skeleton"),l=({rows:e=2,delay:t=600,className:n})=>{const[o]=(0,a.y)(t);return(0,r.jsxs)("div",{className:i("wrapper",{hidden:!o},n),children:[(0,r.jsxs)("div",{className:i("row"),children:[(0,r.jsx)(s.E,{className:i("col-1")}),(0,r.jsx)(s.E,{className:i("col-2")}),(0,r.jsx)(s.E,{className:i("col-3")}),(0,r.jsx)(s.E,{className:i("col-4")}),(0,r.jsx)(s.E,{className:i("col-5")})]}),[...new Array(e)].map(((e,t)=>(0,r.jsx)("div",{className:i("row"),children:(0,r.jsx)(s.E,{className:i("col-full")})},`skeleton-row-${t}`)))]})}},24543:(e,t,n)=>{n.d(t,{u:()=>r});var s=n(59284),o=n(39238),a=n(60712);const r=({children:e,content:t,className:n,pinOnClick:r,hasArrow:i=!0,placement:l=["top","bottom"],...d})=>{const[u,c]=s.useState(!1),[m,p]=s.useState(!1),h=s.useRef(null);return(0,a.jsxs)(s.Fragment,{children:[(0,a.jsx)(o.z,{anchorRef:h,open:m||u,placement:l,hasArrow:i,onOutsideClick:()=>{p(!1)},...d,children:t}),(0,a.jsx)("span",{className:n,ref:h,onClick:r?()=>{p(!0)}:void 0,onMouseEnter:()=>{c(!0)},onMouseLeave:()=>{c(!1)},children:e})]})}},27295:(e,t,n)=>{n.d(t,{LW:()=>u,WT:()=>l,hK:()=>c,or:()=>d});var s=n(56839),o=n(51930),a=n(64036),r=n(78461),i=n(7187);function l(e={}){var t;if(!(0,i.NJ)(e)){const{NodeId:t,PDiskId:n,VSlotId:o}=e;return{StringifiedId:(0,s.U9)({NodeId:t,PDiskId:n,VSlotId:o}),NodeId:t,PDiskId:n,VDiskSlotId:o}}const{PDisk:n,PDiskId:o,VDiskId:r,NodeId:c,Donors:m,AvailableSize:p,AllocatedSize:h,...g}=e,v=n?d({...n,NodeId:null!==(t=null===n||void 0===n?void 0:n.NodeId)&&void 0!==t?t:c}):void 0,f=null!==o&&void 0!==o?o:null===v||void 0===v?void 0:v.PDiskId,S=u({AvailableSize:null!==p&&void 0!==p?p:null===n||void 0===n?void 0:n.AvailableSize,AllocatedSize:h}),k=(0,a.b)(e),y=(0,s.U9)(r);return{...g,...S,VDiskId:r,NodeId:c,PDiskId:f,PDisk:v,Donors:null===m||void 0===m?void 0:m.map((e=>l({...e,DonorMode:!0}))),Severity:k,StringifiedId:y}}function d(e={}){const{AvailableSize:t,TotalSize:n,Category:s,State:a,PDiskId:l,NodeId:d,EnforcedDynamicSlotSize:u,...m}=e,p=(0,i.r$)({nodeId:d,pDiskId:l}),h=(0,r.Y)(s),g=c({AvailableSize:t,TotalSize:n}),v=(0,o.d)({State:a,AllocatedPercent:g.AllocatedPercent});return{...m,...g,PDiskId:l,NodeId:d,StringifiedId:p,Type:h,Category:s,State:a,Severity:v,SlotSize:u}}function u({AvailableSize:e,AllocatedSize:t}){const n=Number(e),s=Number(t),o=s+n;return{AvailableSize:n,AllocatedSize:s,TotalSize:o,AllocatedPercent:Math.floor(100*s/o)}}function c({AvailableSize:e,TotalSize:t}){const n=Number(e),s=Number(t),o=s-n;return{AvailableSize:n,TotalSize:s,AllocatedSize:o,AllocatedPercent:Math.floor(100*o/s)}}},31911:(e,t,n)=>{n.d(t,{A:()=>a});var s=n(48372);const o=JSON.parse('{"node-id":"Node ID","host":"Host","database":"Database","node-name":"Node Name","dc":"DC","rack":"Rack","version":"Version","uptime":"Uptime","memory":"Detailed Memory","ram":"RAM","cpu":"CPU","pools":"Pools","disk-usage":"Disk Usage","tablets":"Tablets","load-average":"Load Average","load":"Load","sessions":"Sessions","missing":"Missing","pdisks":"PDisks","field_memory-used":"Memory used","field_memory-limit":"Memory limit","system-state":"System State","connect-status":"Connect Status","utilization":"Utilization","network-utilization":"Network Utilization","connections":"Connections","clock-skew":"Clock Skew","skew":"Skew","ping-time":"Ping Time","ping":"Ping","send":"Send","receive":"Receive","max":"Max","min":"Min","avg":"Avg","sum":"Sum"}'),a=(0,s.g4)("ydb-nodes-columns",{en:o})},35736:(e,t,n)=>{n.d(t,{w:()=>o});var s=n(76086);function o({inverseColorize:e,warningThreshold:t=s.Hh,dangerThreshold:n=s.Ed,colorizeProgress:o,fillWidth:a}){let r=e?"danger":"good";return o&&(a>t&&a<=n?r="warning":a>n&&(r=e?"good":"danger")),r}},39110:(e,t,n)=>{n.d(t,{r:()=>a});var s=n(48372);const o=JSON.parse('{"slot-id":"VDisk Slot Id","pool-name":"Storage Pool Name","kind":"Kind","guid":"GUID","incarnation-guid":"Incarnation GUID","instance-guid":"Instance GUID","replication-status":"Replicated","state-status":"VDisk State","space-status":"Disk Space","fresh-rank-satisfaction":"Fresh Rank Satisfaction","level-rank-satisfaction":"Level Rank Satisfaction","front-queues":"Front Queues","has-unreadable-blobs":"Has Unreadable Blobs","size":"Size","read-throughput":"Read Throughput","write-throughput":"Write Throughput","links":"Links","vdisk-page":"VDisk page","developer-ui":"Developer UI","yes":"Yes","no":"No","vdiks-title":"VDisk"}'),a=(0,s.g4)("ydb-vDisk-info",{en:o})},40427:(e,t,n)=>{n.d(t,{U3:()=>o,k5:()=>R});const s=!0,o=41;var a=n(59284),r=n(49554);const i=n(21334).F.injectEndpoints({endpoints:function(e){return{fetchTableChunk:e.query({queryFn:async({offset:e,limit:t,sortParams:n,filters:s,columnsIds:o,fetchData:a},{signal:r})=>{try{return{data:await a({limit:t,offset:e,filters:s,sortParams:n,columnsIds:o,signal:r})}}catch(i){return{error:i}}},providesTags:["All"]})}}});var l=n(7435),d=n(90182),u=n(44508),c=n(89169);const m=(0,n(77506).cn)("ydb-paginated-table");function p(e){let t,n=null;return function(...s){t=s,"number"!==typeof n&&(n=requestAnimationFrame((()=>{e(...t),n=null})))}}const h=a.memo;var g=n(60712);const v=({children:e,className:t,height:n,width:s,align:o="left",resizeable:a})=>(0,g.jsx)("td",{className:m("row-cell",{align:o},t),style:{height:`${n}px`,width:`${s}px`,maxWidth:a?`${s}px`:void 0},children:e}),f=h((function({columns:e,height:t}){return(0,g.jsx)("tr",{className:m("row",{loading:!0}),children:e.map((e=>{var n;const o=null!==(n=e.resizeable)&&void 0!==n?n:s;return(0,g.jsx)(v,{height:t,width:e.width,align:e.align,className:e.className,resizeable:o,children:(0,g.jsx)(c.E,{className:m("row-skeleton"),style:{width:"80%",height:"50%"}})},e.name)}))})})),S=({row:e,columns:t,getRowClassName:n,height:o})=>{const a=null===n||void 0===n?void 0:n(e);return(0,g.jsx)("tr",{className:m("row",a),children:t.map((t=>{var n;const a=null!==(n=t.resizeable)&&void 0!==n?n:s;return(0,g.jsx)(v,{height:o,width:t.width,align:t.align,className:t.className,resizeable:a,children:t.render({row:e})},t.name)}))})},k=({columns:e,children:t})=>(0,g.jsx)("tr",{className:m("row",{empty:!0}),children:(0,g.jsx)("td",{colSpan:e.length,className:m("td"),children:t})});var y=n(48372);const b=JSON.parse('{"empty":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445"}'),N=(0,y.g4)("ydb-paginated-table",{ru:b,en:{empty:"No data"}}),D=h((function({id:e,chunkSize:t,calculatedCount:n,rowHeight:s,columns:o,fetchData:r,tableName:c,filters:m,sortParams:p,getRowClassName:h,renderErrorMessage:v,renderEmptyDataMessage:y,onDataFetched:b,isActive:D,keepCache:x}){var w;const[I,C]=a.useState(!0),[P]=(0,d.Nt)(),j={offset:e*t,limit:t,fetchData:r,filters:m,sortParams:p,columnsIds:o.map((e=>e.name)),tableName:c};i.useFetchTableChunkQuery(j,{skip:I||!D,pollingInterval:P,refetchOnMountOrArgChange:!x});const{currentData:E,error:A}=i.endpoints.fetchTableChunk.useQueryState(j);a.useEffect((()=>{let e=0;return D&&I&&(e=window.setTimeout((()=>{C(!1)}),200)),()=>{window.clearTimeout(e)}}),[D,I]),a.useEffect((()=>{E&&D&&b({...E,data:E.data,found:E.found||0,total:E.total||0})}),[E,D,b]);const T=(null===E||void 0===E||null===(w=E.data)||void 0===w?void 0:w.length)||n;return(0,g.jsx)("tbody",{id:e.toString(),style:{height:T*s+"px",display:D?"table-row-group":"block"},children:(()=>{var e;if(!D)return null;if(!E){if(A){const e=A;return(0,g.jsx)(k,{columns:o,children:v?v(e):(0,g.jsx)(u.o,{error:e})})}return(0,l._e)(T).map((e=>(0,g.jsx)(f,{columns:o,height:s},e)))}return null!==(e=E.data)&&void 0!==e&&e.length?E.data.map(((e,t)=>(0,g.jsx)(S,{row:e,columns:o,height:s,getRowClassName:h},t))):(0,g.jsx)(k,{columns:o,children:y?y():N("empty")})})()})}));var x=n(98934);function w({minWidth:e,maxWidth:t,getCurrentColumnWidth:n,onResize:s}){const o=a.useRef(null),[r,i]=a.useState(!1);return a.useEffect((()=>{const a=o.current;if(!a)return;let r,l,d;const u=p((n=>{if(I(n),"number"!==typeof r||"number"!==typeof l)return;const o=n.clientX-r,a=function(e,t=40,n=1/0){return Math.max(t,Math.min(e,n))}(l+o,e,t);a!==d&&(d=a,null===s||void 0===s||s(d))})),c=e=>{I(e),void 0!==d&&(null===s||void 0===s||s(d)),i(!1),r=void 0,document.removeEventListener("mousemove",u),document.removeEventListener("mouseup",c)},m=e=>{l=n(),I(e),r=e.clientX,i(!0),document.addEventListener("mousemove",u),document.addEventListener("mouseup",c)};return a.addEventListener("mousedown",m),()=>{a.removeEventListener("mousedown",m),document.removeEventListener("mousemove",u),document.removeEventListener("mouseup",c)}}),[s,e,t,n]),(0,g.jsx)("span",{ref:o,className:m("resize-handler",{resizing:r}),onClick:e=>I(e)})}function I(e){e.preventDefault(),e.stopPropagation()}const C=({order:e})=>(0,g.jsx)("svg",{className:m("sort-icon",{desc:-1===e}),viewBox:"0 0 10 6",width:"10",height:"6",children:(0,g.jsx)("path",{fill:"currentColor",d:"M0 5h10l-5 -5z"})}),P=({sortOrder:e,sortable:t,defaultSortOrder:n})=>t?(0,g.jsx)("span",{className:m("sort-icon-container",{shadow:!e}),children:(0,g.jsx)(C,{order:e||n})}):null,j={left:"right",right:"left",center:"right"},E=({column:e,resizeable:t,sortOrder:n,defaultSortOrder:s,onSort:o,rowHeight:r,onCellMount:i,onCellUnMount:l,onColumnsResize:d})=>{var u;const c=a.useRef(null);a.useEffect((()=>{const e=c.current;return e&&(null===i||void 0===i||i(e)),()=>{e&&(null===l||void 0===l||l(e))}}),[i,l]);const p=a.useCallback((()=>{var e;return null===(e=c.current)||void 0===e?void 0:e.getBoundingClientRect().width}),[]),h=a.useCallback((t=>{null===d||void 0===d||d(e.name,t)}),[d,e.name]),v=null!==(u=e.header)&&void 0!==u?u:e.name,f={height:`${r}px`,width:`${e.width}px`,minWidth:t?`${e.width}px`:void 0,maxWidth:t?`${e.width}px`:void 0};return(0,g.jsxs)("th",{ref:c,className:m("head-cell-wrapper"),style:f,children:[(0,g.jsxs)("div",{className:m("head-cell",{align:e.align,sortable:e.sortable},e.className),onClick:()=>{e.sortable&&(null===o||void 0===o||o(e.name))},children:[(0,g.jsxs)("div",{className:m("head-cell-content-container"),children:[(0,g.jsx)("div",{className:m("head-cell-content"),children:v}),e.note&&(0,g.jsx)(x.H,{placement:j[e.align],className:m("head-cell-note"),children:e.note})]}),(0,g.jsx)(P,{sortOrder:n,sortable:e.sortable,defaultSortOrder:s})]}),t?(0,g.jsx)(w,{maxWidth:e.resizeMaxWidth,minWidth:e.resizeMinWidth,getCurrentColumnWidth:p,onResize:h}):null]})},A=({columns:e,onSort:t,onColumnsResize:n,defaultSortOrder:r=-1,rowHeight:i=o})=>{const[l,d]=a.useState({}),u=e=>{let n={};if(e===l.columnId){if(l.sortOrder&&l.sortOrder!==r)return d(n),void(null===t||void 0===t||t(n));n={sortOrder:1===l.sortOrder?-1:1,columnId:e}}else n={sortOrder:r,columnId:e};null===t||void 0===t||t(n),d(n)};return(0,g.jsxs)(a.Fragment,{children:[(0,g.jsx)("colgroup",{children:e.map((e=>(0,g.jsx)("col",{style:{width:`${e.width}px`}},e.name)))}),(0,g.jsx)("thead",{className:m("head"),children:(0,g.jsx)("tr",{children:e.map((e=>{var t;const o=l.columnId===e.name?l.sortOrder:void 0,a=n&&(null!==(t=e.resizeable)&&void 0!==t?t:s);return(0,g.jsx)(E,{column:e,resizeable:a,sortOrder:o,defaultSortOrder:r,onSort:u,rowHeight:i,onColumnsResize:n},e.name)}))})})]})},T=({limit:e=20,initialEntitiesCount:t,fetchData:n,filters:s,tableName:i,columns:l,getRowClassName:d,rowHeight:u=o,scrollContainerRef:c,onColumnsResize:h,renderErrorMessage:v,renderEmptyDataMessage:f,containerClassName:S,onDataFetched:k,keepCache:y=!0})=>{const{tableState:b,setSortParams:N,setTotalEntities:x,setFoundEntities:w,setIsInitialLoad:I}=(0,r.WV)(),{sortParams:C,foundEntities:P}=b,j=a.useRef(null),E=(({scrollContainerRef:e,tableRef:t,totalItems:n,rowHeight:s,chunkSize:o,overscanCount:r=1})=>{const i=a.useMemo((()=>Math.ceil(n/o)),[o,n]),[l,d]=a.useState(0),[u,c]=a.useState(Math.min(r,Math.max(i-1,0))),m=a.useCallback((()=>{const n=null===e||void 0===e?void 0:e.current,a=t.current;if(!n||!a)return null;const l=function(e,t){let n=e,s=0;for(;n&&n!==t;)s+=n.offsetTop,n=n.offsetParent;return s}(a,n),d=n.scrollTop,u=Math.max(d-l,0),c=u+n.clientHeight;return{start:Math.max(Math.floor(u/s/o)-r,0),end:Math.min(Math.floor(c/s/o)+r,Math.max(i-1,0))}}),[e,t,s,o,r,i]),h=a.useCallback((()=>{const e=m();e&&(d(e.start),c(e.end))}),[m]);a.useEffect((()=>{h()}),[i,h]);const g=a.useCallback((()=>{h()}),[h]);return a.useEffect((()=>{const e=p((()=>{h()}));return window.addEventListener("resize",e),()=>{window.removeEventListener("resize",e)}}),[h]),a.useEffect((()=>{const t=null===e||void 0===e?void 0:e.current;if(!t)return;const n=p(g);return t.addEventListener("scroll",n),()=>{t.removeEventListener("scroll",n)}}),[g,e]),a.useMemo((()=>{const e=Array(i).fill(!1);for(let t=l;t<=u;t++)e[t]=!0;return e}),[i,l,u])})({scrollContainerRef:c,tableRef:j,totalItems:P,rowHeight:u,chunkSize:e}),[T,U]=a.useState(s);a.useEffect((()=>{U(s)}),[s]);const R=a.useMemo((()=>P?P%e||e:1),[P,e]),G=a.useCallback((e=>{e&&(x(e.total),w(e.found),I(!1),null===k||void 0===k||k(e))}),[k,w,I,x]);a.useLayoutEffect((()=>{const e=t||1;x(t||0),w(e),I(!0)}),[t,x,w,I]);return(0,g.jsx)("div",{ref:j,className:m(null,S),children:(0,g.jsxs)("table",{className:m("table"),children:[(0,g.jsx)(A,{columns:l,onSort:N,onColumnsResize:h}),E.map(((t,s)=>(0,g.jsx)(D,{id:s,calculatedCount:s===E.length-1?R:e,chunkSize:e,rowHeight:u,columns:l,fetchData:n,filters:T,tableName:i,sortParams:C,getRowClassName:d,renderErrorMessage:v,renderEmptyDataMessage:f,onDataFetched:G,isActive:t,keepCache:y},s)))]})})};var U=n(16819);function R({columnsWidthLSKey:e,columns:t,...n}){const[s,o]=(0,U.a)(e),a=function(e,t){return e.map((e=>{var n;return{...e,width:null!==(n=t[e.name])&&void 0!==n?n:e.width}}))}(t,s);return(0,g.jsx)(T,{columns:a,onColumnsResize:o,containerClassName:m("resizeable-table-container"),...n})}},40781:(e,t,n)=>{function s(e,t){const n=e.reduce(((e,n)=>(t[n].forEach((t=>{e.add(t)})),e)),new Set);return Array.from(n).sort()}n.d(t,{R:()=>s})},41775:(e,t,n)=>{n.d(t,{v:()=>i});n(59284);var s=n(77506),o=n(10662),a=n(60712);const r=(0,s.cn)("ydb-search"),i=({onChange:e,value:t="",width:n,className:s,debounce:i,placeholder:l,inputRef:d})=>(0,a.jsx)(o.i,{debounce:i,hasClear:!0,autoFocus:!0,controlRef:d,style:{width:n},className:r(null,s),placeholder:l,value:t,onUpdate:e})},42265:(e,t,n)=>{n.d(t,{o:()=>r});n(59284);var s=n(69326),o=n(49554),a=n(60712);const r=({controls:e,table:t,tableProps:n,error:r,initialState:i,fullHeight:l=!0})=>(0,a.jsx)(o.jV,{initialState:i,children:(0,a.jsxs)(s.L,{fullHeight:l,children:[(0,a.jsx)(s.L.Controls,{children:e}),r,(0,a.jsx)(s.L.Table,{...n||{},children:t})]})})},43951:(e,t,n)=>{n.d(t,{K:()=>a});var s=n(59284),o=n(59001);const a=(e,t,n,a,r)=>{const[i,l]=s.useState((()=>o.f.readUserSettingsValue(t,a)));return{columnsToShow:s.useMemo((()=>e.filter((e=>{const t=e.name,n=i.includes(t),s=null===r||void 0===r?void 0:r.includes(t);return n||s}))),[e,r,i]),columnsToSelect:s.useMemo((()=>e.map((e=>e.name)).map((e=>{const t=null===r||void 0===r?void 0:r.includes(e),s=i.includes(e);return{id:e,title:n[e],selected:t||s,required:t,sticky:t?"start":void 0}}))),[e,n,r,i]),setColumns:s.useCallback((e=>{const n=e.filter((e=>e.selected)).map((e=>e.id));o.f.setUserSettingsValue(t,n),l(n)}),[t])}}},47199:(e,t,n)=>{n.d(t,{z:()=>Ge});var s=n(12888),o=n(59284),a=n(98167),r=n(67028),i=n(80987),l=n(370);const d={all:"all",missing:"missing",space:"space"},u={groups:"groups",nodes:"nodes"},c=l.z.nativeEnum(d).catch(d.all),m=l.z.nativeEnum(u).catch(u.groups);var p=n(78034),h=n(74319),g=n(86782);const v=["NodeId","Host","Uptime","CPU","RAM","PDisks"],f=["NodeId"],S=["Host","DC","Rack","Version","Uptime","Missing","DiskSpaceUsage"],k=S.map((e=>({value:e,content:(0,g.kn)(e)}))),y=l.z.custom((e=>S.includes(e))).catch(void 0);function b(){var e;const[t,n]=(0,i.useQueryParams)({type:i.StringParam,visible:i.StringParam,search:i.StringParam,uptimeFilter:i.StringParam,storageNodesGroupBy:i.StringParam,storageGroupsGroupBy:i.StringParam}),s=m.parse(t.type),o=c.parse(t.visible),a=null!==(e=t.search)&&void 0!==e?e:"",r=p.Bm.parse(t.uptimeFilter),l=h.kY.parse(t.storageGroupsGroupBy),d=y.parse(t.storageNodesGroupBy),u=e=>{n({visible:e},"replaceIn")},g=e=>{n({uptimeFilter:e},"replaceIn")};return{storageType:s,visibleEntities:o,searchValue:a,nodesUptimeFilter:r,storageGroupsGroupByParam:l,storageNodesGroupByParam:d,handleTextFilterChange:e=>{n({search:e||void 0},"replaceIn")},handleVisibleEntitiesChange:u,handleStorageTypeChange:e=>{n({type:e},"replaceIn")},handleUptimeFilterChange:g,handleStorageGroupsGroupByParamChange:e=>{n({storageGroupsGroupBy:e},"replaceIn")},handleStorageNodesGroupByParamChange:e=>{n({storageNodesGroupBy:e},"replaceIn")},handleShowAllGroups:()=>{u("all")},handleShowAllNodes:()=>{u("all"),g(p.cW.All)}}}var N=n(79553),D=n(42265),x=n(10174),w=n(90182),I=n(81101),C=n(40427),P=n(10731),j=n(91157),E=n(60712);const A=({visibleEntities:e,onShowAll:t})=>{let n;return e===d.space&&(n=(0,j.A)("empty.out_of_space")),e===d.missing&&(n=(0,j.A)("empty.degraded")),n?(0,E.jsx)(P.U,{title:n,showAll:(0,j.A)("show_all"),onShowAll:t}):null};var T=n(16029),U=n(69464),R=n(40781);const G=({columns:e,database:t,nodeId:n,groupId:s,pDiskId:i,filterGroup:l,filterGroupBy:u,searchValue:c,visibleEntities:m,onShowAll:p,scrollContainerRef:g,renderErrorMessage:v,initialEntitiesCount:f})=>{const S=(0,r.Pm)(),k=(0,r.YA)(),y=(b=k,o.useCallback((async e=>{const{limit:t,offset:n,sortParams:s,filters:o,columnsIds:a}=e,{sortOrder:r,columnId:i}=null!==s&&void 0!==s?s:{},{searchValue:l,visibleEntities:d,database:u,nodeId:c,groupId:m,pDiskId:p,filterGroup:g,filterGroupBy:v}=null!==o&&void 0!==o?o:{},f=(0,h.GP)(i),S=f?(0,U.T)(f,r):void 0,k=(0,R.R)(a,h.YX),{groups:y,found:N,total:D}=await(0,T.t)({limit:t,offset:n,sort:S,filter:l,with:d,database:u,nodeId:c,groupId:m,pDiskId:p,filter_group:g,filter_group_by:v,fieldsRequired:k,shouldUseGroupsHandler:b});return{data:y||[],found:N||0,total:D||0}}),[b]));var b;const N=o.useMemo((()=>({searchValue:c,visibleEntities:m,database:t,nodeId:n,groupId:s,pDiskId:i,filterGroup:l,filterGroupBy:u})),[c,m,t,n,s,i,l,u]);return(0,E.jsx)(a.r,{loading:!S,children:(0,E.jsx)(C.k5,{columnsWidthLSKey:h.qK,scrollContainerRef:g,columns:e,fetchData:y,initialEntitiesCount:f,renderErrorMessage:v,renderEmptyDataMessage:()=>m!==d.all?(0,E.jsx)(A,{onShowAll:p,visibleEntities:m}):(0,j.A)("empty.default"),filters:N,tableName:"storage-groups"})})};var M=n(43951),L=n(74006);function z({visibleEntities:e,viewContext:t}){const n=(0,s.X)(),a=o.useMemo((()=>{const e=(0,L.J)({viewContext:t});return n?e:e.filter((e=>!(0,h.Ai)(e.name)))}),[n,t]),r=o.useMemo((()=>e===d.missing?[...h.LO,h.UW.Degraded]:e===d.space?[...h.LO,h.UW.DiskSpace]:h.LO),[e]);return(0,M.K)(a,h.zY,h.H6,h.hu,r)}var V=n(71708),W=n(62710),F=n(48372);const O=JSON.parse('{"groups":"Groups","nodes":"Nodes","controls_groups-search-placeholder":"Group ID, Pool name","controls_nodes-search-placeholder":"Node ID, FQDN","controls_group-by-placeholder":"Group by:","no-nodes":"No such nodes","no-groups":"No such groups"}'),H=(0,F.g4)("ydb-storage",{en:O});var _=n(77506);const B=(0,_.cn)("global-storage");var $=n(69775),Y=n(98089),K=n(24555),J=n(53755),Q=n(49554),X=n(41775),q=n(44433);const Z={[u.groups]:"Groups",[u.nodes]:"Nodes"},ee=({value:e,onChange:t})=>(0,E.jsxs)(q.a,{value:e,onUpdate:t,qa:"storage-type-filter",children:[(0,E.jsx)(q.a.Option,{value:u.groups,children:Z[u.groups]}),(0,E.jsx)(q.a.Option,{value:u.nodes,children:Z[u.nodes]})]}),te={[d.all]:"All",[d.missing]:"Degraded",[d.space]:"Out of Space"},ne=({value:e,onChange:t})=>(0,E.jsxs)(q.a,{value:e,onUpdate:t,qa:"storage-visible-entities-filter",children:[(0,E.jsx)(q.a.Option,{value:d.missing,children:te[d.missing]}),(0,E.jsx)(q.a.Option,{value:d.space,children:te[d.space]}),(0,E.jsx)(q.a.Option,{value:d.all,children:te[d.all]})]});function se({withTypeSelector:e,withGroupBySelect:t,entitiesCountCurrent:n,entitiesCountTotal:a,entitiesLoading:r,columnsToSelect:i,handleSelectedColumnsUpdate:l}){const{searchValue:d,storageType:u,visibleEntities:c,storageGroupsGroupByParam:m,handleTextFilterChange:p,handleStorageTypeChange:g,handleVisibleEntitiesChange:v,handleStorageGroupsGroupByParamChange:f}=b(),S=(0,s.X)(),k=e&&S;return(0,E.jsxs)(o.Fragment,{children:[(0,E.jsx)(X.v,{value:d,onChange:p,placeholder:H("controls_groups-search-placeholder"),className:B("search")}),k&&(0,E.jsx)(ee,{value:u,onChange:g}),t?null:(0,E.jsx)(ne,{value:c,onChange:v}),(0,E.jsx)($.O,{popupWidth:200,items:i,showStatus:!0,onUpdate:l,sortable:!1}),t?(0,E.jsxs)(o.Fragment,{children:[(0,E.jsx)(Y.E,{variant:"body-2",children:H("controls_group-by-placeholder")}),(0,E.jsx)(K.l,{hasClear:!0,placeholder:"-",width:150,defaultValue:m?[m]:void 0,onUpdate:e=>{f(e[0])},options:h.SE})]}):null,(0,E.jsx)(J.T,{label:H("groups"),loading:r,total:a,current:n})]})}function oe({withTypeSelector:e,withGroupBySelect:t,columnsToSelect:n,handleSelectedColumnsUpdate:s}){const{tableState:o}=(0,Q.WV)();return(0,E.jsx)(se,{withTypeSelector:e,withGroupBySelect:t,entitiesCountCurrent:o.foundEntities,entitiesCountTotal:o.totalEntities,entitiesLoading:o.isInitialLoad,columnsToSelect:n,handleSelectedColumnsUpdate:s})}const ae=o.memo((function({name:e,count:t,isExpanded:n,database:s,nodeId:o,groupId:a,pDiskId:r,searchValue:i,scrollContainerRef:l,filterGroupBy:d,columns:u,onIsExpandedChange:c,handleShowAllGroups:m}){return(0,E.jsx)(V.Q,{title:e,count:t,entityName:H("groups"),expanded:n,onIsExpandedChange:c,children:(0,E.jsx)(G,{database:s,scrollContainerRef:l,nodeId:o,groupId:a,pDiskId:r,filterGroup:e,filterGroupBy:d,searchValue:i,visibleEntities:"all",onShowAll:m,renderErrorMessage:I.$,columns:u,initialEntitiesCount:t})},e)}));function re({database:e,nodeId:t,groupId:n,pDiskId:s,scrollContainerRef:a,viewContext:r}){const[i]=(0,w.Nt)(),{searchValue:l,storageGroupsGroupByParam:d,visibleEntities:u,handleShowAllGroups:c}=b(),{columnsToShow:m,columnsToSelect:p,setColumns:h}=z({visibleEntities:u,viewContext:r}),{currentData:g,isFetching:v,error:f}=x.S.useGetStorageGroupsInfoQuery({database:e,with:"all",nodeId:t,groupId:n,pDiskId:s,filter:l,shouldUseGroupsHandler:!0,group:d},{pollingInterval:i}),S=void 0===g&&v,{tableGroups:k,found:y=0,total:I=0}=g||{},{expandedGroups:C,setIsGroupExpanded:P}=(0,W.$)(k),j=o.useMemo((()=>({foundEntities:y,totalEntities:I,isInitialLoad:S,sortParams:void 0})),[y,I,S]);return(0,E.jsx)(D.o,{controls:(0,E.jsx)(se,{withTypeSelector:!0,withGroupBySelect:!0,entitiesCountCurrent:y,entitiesCountTotal:I,entitiesLoading:S,columnsToSelect:p,handleSelectedColumnsUpdate:h}),error:f?(0,E.jsx)(N.o,{error:f}):null,table:null!==k&&void 0!==k&&k.length?k.map((({name:o,count:r})=>{const i=C[o];return(0,E.jsx)(ae,{name:o,count:r,isExpanded:i,database:e,nodeId:t,groupId:n,pDiskId:s,filterGroupBy:d,searchValue:l,visibleEntities:"all",scrollContainerRef:a,onIsExpandedChange:P,handleShowAllGroups:c,columns:m},o)})):H("no-groups"),initialState:j,tableProps:{scrollContainerRef:a,scrollDependencies:[l,d,k],loading:S,className:B("groups-wrapper")}})}function ie({database:e,nodeId:t,groupId:n,pDiskId:s,viewContext:o,scrollContainerRef:a,initialEntitiesCount:i}){const{searchValue:l,visibleEntities:d,handleShowAllGroups:u}=b(),c=(0,r.SA)(),{columnsToShow:m,columnsToSelect:p,setColumns:h}=z({visibleEntities:d,viewContext:o});return(0,E.jsx)(D.o,{controls:(0,E.jsx)(oe,{withTypeSelector:!0,withGroupBySelect:c,columnsToSelect:p,handleSelectedColumnsUpdate:h}),table:(0,E.jsx)(G,{database:e,nodeId:t,groupId:n,pDiskId:s,searchValue:l,visibleEntities:d,onShowAll:u,scrollContainerRef:a,renderErrorMessage:I.$,columns:m,initialEntitiesCount:i}),tableProps:{scrollContainerRef:a,scrollDependencies:[l,d]},fullHeight:!0})}function le(e){const{storageGroupsGroupByParam:t,visibleEntities:n,handleShowAllGroups:s}=b(),i=(0,r.Pm)(),l=(0,r.SA)();o.useEffect((()=>{l&&"all"!==n&&s()}),[s,l,n]);return(0,E.jsx)(a.r,{loading:!i,children:l&&t?(0,E.jsx)(re,{...e}):(0,E.jsx)(ie,{...e})})}var de=n(44508);const ue=JSON.parse('{"empty.default":"No such nodes","empty.out_of_space":"No nodes with out of space errors","empty.degraded":"No degraded nodes","empty.small_uptime":"No nodes with uptime < 1h","empty.several_filters":"No nodes match current filters combination","show_all":"Show all nodes"}'),ce=JSON.parse('{"empty.default":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432","empty.out_of_space":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432, \u0432 \u043a\u043e\u0442\u043e\u0440\u044b\u0445 \u043a\u043e\u043d\u0447\u0430\u0435\u0442\u0441\u044f \u043c\u0435\u0441\u0442\u043e","empty.degraded":"\u041d\u0435\u0442 \u0434\u0435\u0433\u0440\u0430\u0434\u0438\u0440\u043e\u0432\u0430\u0432\u0448\u0438\u0445 \u0443\u0437\u043b\u043e\u0432","empty.small_uptime":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432 \u0441 uptime < 1h","empty.several_filters":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432, \u043f\u043e\u0434\u0445\u043e\u0434\u044f\u0449\u0438\u0445 \u043f\u043e\u0434 \u0442\u0435\u043a\u0443\u0449\u0438\u0435 \u0444\u0438\u043b\u044c\u0442\u0440\u044b","show_all":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435 \u0443\u0437\u043b\u044b"}'),me=(0,F.g4)("ydb-storage-nodes",{ru:ce,en:ue}),pe=({visibleEntities:e,nodesUptimeFilter:t,onShowAll:n})=>{let s;return e===d.space&&(s=me("empty.out_of_space")),e===d.missing&&(s=me("empty.degraded")),t===p.cW.SmallUptime&&(s=me("empty.small_uptime")),e!==d.all&&t!==p.cW.All&&(s=me("empty.several_filters")),s?(0,E.jsx)(P.U,{title:s,showAll:me("show_all"),onShowAll:n}):null};var he=n(11905);const ge=async e=>{const{type:t="static",storage:n=!0,limit:s,offset:o,sortParams:a,filters:r,columnsIds:i}=e,{searchValue:l,nodesUptimeFilter:d,visibleEntities:u,database:c,nodeId:m,groupId:h,filterGroup:v,filterGroupBy:f}=null!==r&&void 0!==r?r:{},{sortOrder:S,columnId:k}=null!==a&&void 0!==a?a:{},y=(0,g.kU)(k),b=y?(0,U.T)(y,S):void 0,N=(0,R.R)(i,g.fN),D=await window.api.viewer.getNodes({type:t,storage:n,limit:s,offset:o,sort:b,filter:l,uptime:(0,p.Fo)(d),with:u,database:c,node_id:m,group_id:h,filter_group:v,filter_group_by:f,fieldsRequired:N}),x=(0,he.rz)(D);return{data:x.nodes||[],found:x.found||0,total:x.total||0,columnsSettings:x.columnsSettings}},ve=(0,_.cn)("ydb-storage-nodes"),fe=e=>ve("node",{unavailable:(0,p.X7)(e)}),Se=({columns:e,database:t,nodeId:n,groupId:s,filterGroup:a,filterGroupBy:r,searchValue:i,visibleEntities:l,nodesUptimeFilter:u,onShowAll:c,scrollContainerRef:m,renderErrorMessage:h,initialEntitiesCount:g,onDataFetched:v})=>{const f=o.useMemo((()=>({searchValue:i,visibleEntities:l,nodesUptimeFilter:u,database:t,nodeId:n,groupId:s,filterGroup:a,filterGroupBy:r})),[i,l,u,t,n,s,a,r]);return(0,E.jsx)(C.k5,{columnsWidthLSKey:"storageNodesColumnsWidth",scrollContainerRef:m,columns:e,fetchData:ge,rowHeight:51,initialEntitiesCount:g,renderErrorMessage:h,renderEmptyDataMessage:()=>l!==d.all||u!==p.cW.All?(0,E.jsx)(pe,{onShowAll:c,nodesUptimeFilter:u,visibleEntities:l}):me("empty.default"),getRowClassName:fe,filters:f,tableName:"storage-nodes",onDataFetched:v})};var ke=n(156),ye=n(64934);function be({withTypeSelector:e,withGroupBySelect:t,entitiesCountCurrent:n,entitiesCountTotal:s,entitiesLoading:a,columnsToSelect:r,handleSelectedColumnsUpdate:i}){const{searchValue:l,storageType:d,visibleEntities:u,nodesUptimeFilter:c,storageNodesGroupByParam:m,handleTextFilterChange:p,handleStorageTypeChange:h,handleVisibleEntitiesChange:g,handleUptimeFilterChange:v,handleStorageNodesGroupByParamChange:f}=b();return(0,E.jsxs)(o.Fragment,{children:[(0,E.jsx)(X.v,{value:l,onChange:p,placeholder:H("controls_nodes-search-placeholder"),className:B("search")}),e&&(0,E.jsx)(ee,{value:d,onChange:h}),t?null:(0,E.jsx)(ne,{value:u,onChange:g}),t?null:(0,E.jsx)(ye.j,{value:c,onChange:v}),(0,E.jsx)($.O,{popupWidth:200,items:r,showStatus:!0,onUpdate:i,sortable:!1}),t?(0,E.jsxs)(o.Fragment,{children:[(0,E.jsx)(Y.E,{variant:"body-2",children:H("controls_group-by-placeholder")}),(0,E.jsx)(K.l,{hasClear:!0,placeholder:"-",width:150,defaultValue:m?[m]:void 0,onUpdate:e=>{f(e[0])},options:k})]}):null,(0,E.jsx)(J.T,{label:H("nodes"),loading:a,total:s,current:n})]})}function Ne({withTypeSelector:e,withGroupBySelect:t,columnsToSelect:n,handleSelectedColumnsUpdate:s}){const{tableState:o}=(0,Q.WV)();return(0,E.jsx)(be,{withTypeSelector:e,withGroupBySelect:t,entitiesCountCurrent:o.foundEntities,entitiesCountTotal:o.totalEntities,entitiesLoading:o.isInitialLoad,columnsToSelect:n,handleSelectedColumnsUpdate:s})}var De=n(88655),xe=n(4557),we=n(78762),Ie=n(10576);const Ce=(0,_.cn)("ydb-storage-nodes-columns"),Pe=({viewContext:e,columnsSettings:t})=>({name:g.vg.PDisks,header:g.uG.PDisks,className:Ce("pdisks-column"),width:null===t||void 0===t?void 0:t.pDiskContainerWidth,render:({row:n})=>{var s;return(0,E.jsx)("div",{className:Ce("pdisks-wrapper"),children:null===(s=n.PDisks)||void 0===s?void 0:s.map((s=>{var o;const a=null===(o=n.VDisks)||void 0===o?void 0:o.filter((e=>e.PDiskId===s.PDiskId));return(0,E.jsx)("div",{className:Ce("pdisks-item"),children:(0,E.jsx)(Ie.E,{data:s,vDisks:a,viewContext:e,width:null===t||void 0===t?void 0:t.pDiskWidth})},s.PDiskId)}))})},align:xe.Ay.CENTER,sortable:!1,resizeable:!1});function je({visibleEntities:e,database:t,additionalNodesProps:n,viewContext:s,columnsSettings:a}){const r=o.useMemo((()=>(({database:e,additionalNodesProps:t,viewContext:n,columnsSettings:s})=>{const o=null===t||void 0===t?void 0:t.getNodeRef;return[(0,we._E)(),(0,we.Nh)({getNodeRef:o,database:e}),(0,we.eT)(),(0,we.uk)(),(0,we.OX)(),(0,we.jl)(),(0,we.fr)(),(0,we.kv)(),(0,we.pH)(),(0,we.iX)(),(0,we.Bg)(),(0,we.Rn)(),(0,we.Vz)(),Pe({viewContext:n,columnsSettings:s})].map((e=>({...e,sortable:(0,g.sp)(e.name)})))})({database:t,additionalNodesProps:n,viewContext:s,columnsSettings:a})),[t,n,s,a]),i=o.useMemo((()=>e===d.missing?[...f,g.vg.Missing]:f),[e]);return(0,M.K)(r,"storageNodesSelectedColumns",g.uG,v,i)}function Ee({database:e,viewContext:t,columnsSettings:n}){const s=(0,De.E)(),{visibleEntities:o}=b();return je({additionalNodesProps:s,visibleEntities:o,database:e,viewContext:t,columnsSettings:n})}const Ae=o.memo((function({name:e,count:t,isExpanded:n,database:s,nodeId:o,groupId:a,searchValue:r,scrollContainerRef:i,filterGroupBy:l,columns:d,onIsExpandedChange:u,handleShowAllNodes:c,onDataFetched:m}){return(0,E.jsx)(V.Q,{title:e,count:t,entityName:H("nodes"),expanded:n,onIsExpandedChange:u,children:(0,E.jsx)(Se,{database:s,scrollContainerRef:i,nodeId:o,groupId:a,filterGroup:e,filterGroupBy:l,searchValue:r,visibleEntities:"all",nodesUptimeFilter:p.cW.All,onShowAll:c,renderErrorMessage:I.$,columns:d,initialEntitiesCount:t,onDataFetched:m})},e)}));function Te({database:e,groupId:t,nodeId:n,viewContext:s,scrollContainerRef:a}){const[r]=(0,w.Nt)(),{searchValue:i,storageNodesGroupByParam:l,handleShowAllNodes:d}=b(),{handleDataFetched:u,columnsSettings:c}=(0,ke.fj)(),{columnsToShow:m,columnsToSelect:p,setColumns:h}=Ee({database:e,viewContext:s,columnsSettings:c}),{currentData:g,isFetching:v,error:f}=x.S.useGetStorageNodesInfoQuery({database:e,with:"all",filter:i,node_id:n,group_id:t,group:l},{pollingInterval:r}),S=void 0===g&&v,{tableGroups:k,found:y=0,total:N=0}=g||{},{expandedGroups:I,setIsGroupExpanded:C}=(0,W.$)(k),P=o.useMemo((()=>({foundEntities:y,totalEntities:N,isInitialLoad:S,sortParams:void 0})),[y,N,S]);return(0,E.jsx)(D.o,{controls:(0,E.jsx)(be,{withTypeSelector:!0,withGroupBySelect:!0,entitiesCountCurrent:y,entitiesCountTotal:N,entitiesLoading:S,columnsToSelect:p,handleSelectedColumnsUpdate:h}),error:f?(0,E.jsx)(de.o,{error:f}):null,table:null!==k&&void 0!==k&&k.length?k.map((({name:s,count:o})=>{const r=I[s];return(0,E.jsx)(Ae,{name:s,count:o,isExpanded:r,database:e,nodeId:n,groupId:t,searchValue:i,visibleEntities:"all",filterGroupBy:l,scrollContainerRef:a,onIsExpandedChange:C,handleShowAllNodes:d,columns:m,onDataFetched:u},s)})):H("no-nodes"),initialState:P,tableProps:{scrollContainerRef:a,scrollDependencies:[i,l,k],loading:S,className:B("groups-wrapper")}})}function Ue({database:e,nodeId:t,groupId:n,viewContext:s,scrollContainerRef:o,initialEntitiesCount:a}){const{searchValue:i,visibleEntities:l,nodesUptimeFilter:d,handleShowAllNodes:u}=b(),c=(0,r.Ye)(),{handleDataFetched:m,columnsSettings:p}=(0,ke.fj)(),{columnsToShow:h,columnsToSelect:g,setColumns:v}=Ee({database:e,viewContext:s,columnsSettings:p});return(0,E.jsx)(D.o,{controls:(0,E.jsx)(Ne,{withTypeSelector:!0,withGroupBySelect:c,columnsToSelect:g,handleSelectedColumnsUpdate:v}),table:(0,E.jsx)(Se,{database:e,nodeId:t,groupId:n,searchValue:i,visibleEntities:l,nodesUptimeFilter:d,onShowAll:u,scrollContainerRef:o,renderErrorMessage:I.$,columns:h,initialEntitiesCount:a,onDataFetched:m}),tableProps:{scrollContainerRef:o,scrollDependencies:[i,l,d]},fullHeight:!0})}function Re(e){const{storageNodesGroupByParam:t,visibleEntities:n,nodesUptimeFilter:s,handleShowAllNodes:i}=b(),l=(0,r.Pm)(),d=(0,r.Ye)();o.useEffect((()=>{!d||"all"===n&&s===p.cW.All||i()}),[i,s,d,n]);return(0,E.jsx)(a.r,{loading:!l,children:d&&t?(0,E.jsx)(Te,{...e}):(0,E.jsx)(Ue,{...e})})}const Ge=e=>{const{storageType:t}=b(),n=(0,s.X)();return"nodes"===t&&n?(0,E.jsx)(Re,{initialEntitiesCount:(0,ke.b0)(e.viewContext),...e}):(0,E.jsx)(le,{initialEntitiesCount:(0,ke.QQ)(e.viewContext),...e})}},48295:(e,t,n)=>{n.d(t,{_:()=>u});var s=n(77506),o=n(24543),a=n(80176),r=n(60712);const i=(0,s.cn)("ydb-pool-bar"),l=({data:e={}})=>{const{Usage:t=0}=e,n=Math.min(100*t,100),s=(e=>e>=75?"danger":e>=50&&e<75?"warning":"normal")(n);return(0,r.jsx)(o.u,{className:i({type:s}),content:(0,r.jsx)(a.HG,{data:e,className:i("popup-content")}),children:(0,r.jsx)("div",{style:{height:`${n}%`},className:i("value",{type:s})})})},d=(0,s.cn)("ydb-pools-graph"),u=({pools:e=[]})=>(0,r.jsx)("div",{className:d(),children:e.map(((e,t)=>(0,r.jsx)(l,{data:e},t)))})},49554:(e,t,n)=>{n.d(t,{WV:()=>l,jV:()=>i});var s=n(59284),o=n(60712);const a={sortParams:void 0,totalEntities:0,foundEntities:0,isInitialLoad:!0},r=s.createContext({tableState:a,setSortParams:()=>{},setTotalEntities:()=>{},setFoundEntities:()=>{},setIsInitialLoad:()=>{}}),i=({children:e,initialState:t={}})=>{var n,i,l,d;const[u,c]=s.useState(null!==(n=t.sortParams)&&void 0!==n?n:a.sortParams),[m,p]=s.useState(null!==(i=t.totalEntities)&&void 0!==i?i:a.totalEntities),[h,g]=s.useState(null!==(l=t.foundEntities)&&void 0!==l?l:a.foundEntities),[v,f]=s.useState(null!==(d=t.isInitialLoad)&&void 0!==d?d:a.isInitialLoad),S=s.useMemo((()=>({sortParams:u,totalEntities:m,foundEntities:h,isInitialLoad:v})),[u,m,h,v]),k=s.useMemo((()=>({tableState:S,setSortParams:c,setTotalEntities:p,setFoundEntities:g,setIsInitialLoad:f})),[S,c,p,g,f]);return(0,o.jsx)(r.Provider,{value:k,children:e})},l=()=>{const e=s.useContext(r);if(void 0===e)throw new Error("usePaginatedTableState must be used within a PaginatedTableStateProvider");return e}},50672:(e,t,n)=>{n.d(t,{D:()=>a});var s=n(48372);const o=JSON.parse('{"type":"Type","path":"Path","guid":"GUID","serial-number":"Serial Number","shared-with-os":"SharedWithOs","drive-status":"Drive Status","state":"State","device":"Device","realtime":"Realtime","space":"Space","slots":"Slots","log-size":"Log Size","system-size":"System Size","links":"Links","developer-ui":"Developer UI","pdisk-page":"PDisk page","yes":"Yes"}'),a=(0,s.g4)("ydb-pDisk-info",{en:o})},51930:(e,t,n)=>{n.d(t,{d:()=>a});var s=n(5707),o=n(7187);function a(e){const t=function(e){return t=e,void 0!==t&&t in s.iZ?s.iZ[e]:s.Km;var t}(e.State),n=(0,o.SW)(e.AllocatedPercent);return t!==s.Km&&n?Math.max(t,n):t}},53755:(e,t,n)=>{n.d(t,{T:()=>l});var s=n(47665),o=n(77506);const a=(0,n(48372).g4)("ydb-entities-count",{ru:{of:"\u0438\u0437"},en:{of:"of"}});var r=n(60712);const i=(0,o.cn)("ydb-entities-count"),l=({total:e,current:t,label:n,loading:o,className:l})=>{let d="";return n&&(d+=`${n}: `),o?d+="...":(d+=`${t}`,e&&Number(e)!==Number(t)&&(d+=` ${a("of")} ${e}`)),(0,r.jsx)(s.J,{theme:"info",size:"m",className:i(null,l),children:d})}},58267:(e,t,n)=>{n.d(t,{P:()=>r,_:()=>i});var s=n(54090),o=n(6354);const a={[o.r.Dead]:s.m.Red,[o.r.Created]:s.m.Yellow,[o.r.ResolveStateStorage]:s.m.Yellow,[o.r.Candidate]:s.m.Yellow,[o.r.BlockBlobStorage]:s.m.Yellow,[o.r.WriteZeroEntry]:s.m.Yellow,[o.r.Restored]:s.m.Yellow,[o.r.Discover]:s.m.Yellow,[o.r.Lock]:s.m.Yellow,[o.r.Stopped]:s.m.Yellow,[o.r.ResolveLeader]:s.m.Yellow,[o.r.RebuildGraph]:s.m.Yellow,[o.r.Deleted]:s.m.Green,[o.r.Active]:s.m.Green},r=e=>{if(!e)return s.m.Grey;return t=e,Object.values(s.m).includes(t)?e:a[e];var t};function i(e){if(!e)return"unknown";switch(e){case o.r.Dead:return"danger";case o.r.Active:case o.r.Deleted:return"success";default:return"warning"}}},62710:(e,t,n)=>{n.d(t,{$:()=>o});var s=n(59284);function o(e){const[t,n]=s.useState({});s.useEffect((()=>{null!==e&&void 0!==e&&e.length&&n((t=>e.reduce(((e,{name:n})=>{const s=t[n];return{...e,[n]:null!==s&&void 0!==s&&s}}),{})))}),[e]);return{expandedGroups:t,setIsGroupExpanded:s.useCallback(((e,t)=>{n((n=>({...n,[e]:t})))}),[])}}},64036:(e,t,n)=>{n.d(t,{b:()=>a});var s=n(54090),o=n(5707);function a(e){const{DiskSpace:t,VDiskState:n,FrontQueues:s,Replicated:a}=e;if(!n)return o.Km;const i=r(t),l=function(e){var t;if(!e)return o.Km;return null!==(t=o.qs[e])&&void 0!==t?t:o.Km}(n),d=Math.min(o.aW.Orange,r(s));let u=Math.max(i,l,d);return!1===a&&u===o.aW.Green&&(u=o.aW.Blue),u}function r(e){var t;return e?e===s.m.Blue?o.aW.Green:null!==(t=o.aW[e])&&void 0!==t?t:o.Km:o.Km}},64934:(e,t,n)=>{n.d(t,{j:()=>r});var s=n(44433),o=n(78034),a=n(60712);const r=({value:e,onChange:t,className:n})=>(0,a.jsxs)(s.a,{value:e,onUpdate:t,className:n,children:[(0,a.jsx)(s.a.Option,{value:o.cW.All,children:o.DG[o.cW.All]}),(0,a.jsx)(s.a.Option,{value:o.cW.SmallUptime,children:o.DG[o.cW.SmallUptime]})]})},67375:(e,t,n)=>{n.d(t,{W:()=>s});let s=function(e){return e.Initial="Initial",e.LocalRecoveryError="LocalRecoveryError",e.SyncGuidRecovery="SyncGuidRecovery",e.SyncGuidRecoveryError="SyncGuidRecoveryError",e.OK="OK",e.PDiskError="PDiskError",e}({})},69326:(e,t,n)=>{n.d(t,{L:()=>d});var s=n(59284),o=n(87184),a=n(77506),r=n(19228);var i=n(60712);const l=(0,a.cn)("ydb-table-with-controls-layout"),d=({children:e,className:t,fullHeight:n})=>(0,i.jsx)("div",{className:l({"full-height":n},t),children:e});d.Controls=function({children:e,renderExtraControls:t,className:n}){return(0,i.jsxs)(o.s,{justifyContent:"space-between",alignItems:"center",className:l("controls-wrapper"),gap:2,children:[(0,i.jsx)("div",{className:l("controls",n),children:e}),null===t||void 0===t?void 0:t()]})},d.Table=function({children:e,loading:t,className:n,scrollContainerRef:o,scrollDependencies:a=[]}){const d=s.useRef(null);return(({tableContainerRef:e,scrollContainerRef:t,dependencies:n=[]})=>{const o=s.useCallback((()=>{if(null!==e&&void 0!==e&&e.current){const t=window.getComputedStyle(e.current).getPropertyValue("--data-table-sticky-header-offset");return t?parseInt(t,10):0}return 0}),[e]),a=s.useCallback((()=>{if(null!==e&&void 0!==e&&e.current&&null!==t&&void 0!==t&&t.current){const n=o(),s=e.current.getBoundingClientRect(),a=t.current.getBoundingClientRect(),r=s.top-a.top+t.current.scrollTop;s.top-n{e&&t&&a()}),[a,e,t,...n])})({tableContainerRef:d,scrollContainerRef:o,dependencies:a}),t?(0,i.jsx)(r.Q,{className:l("loader")}):(0,i.jsx)("div",{ref:d,className:l("table",n),children:e})}},69464:(e,t,n)=>{n.d(t,{T:()=>o});var s=n(6388);n(23536);const o=(e,t=s.xN)=>t===s.xN?`-${e}`:e},71708:(e,t,n)=>{n.d(t,{Q:()=>d});n(59284);var s=n(33705),o=n(98089),a=n(47665),r=n(77506),i=n(60712);const l=(0,r.cn)("ydb-table-group"),d=({children:e,title:t,entityName:n,count:r,expanded:d=!1,onIsExpandedChange:u})=>{const c=()=>{u(t,!d)};return(0,i.jsxs)("div",{className:l(null),children:[(0,i.jsx)("button",{onClick:c,className:l("button"),title:t,children:(0,i.jsxs)("div",{className:l("title-wrapper"),children:[(0,i.jsx)(s.I,{direction:d?"top":"bottom"}),(0,i.jsxs)("div",{className:l("title"),children:[(0,i.jsx)(o.E,{variant:"subheader-2",children:t}),(0,i.jsxs)(o.E,{variant:"body-2",color:"secondary",className:l("count"),children:[n,": ",(0,i.jsx)(a.J,{theme:"normal",children:r})]})]})]})}),d?(0,i.jsx)("div",{className:l("content"),children:e}):null]})};d.displayName="TableGroup"},73473:(e,t,n)=>{n.d(t,{S:()=>b});var s=n(38501),o=n(23900),a=n(46549),r=n(77506),i=n(76086),l=n(35736),d=n(41650),u=n(13096),c=n(15132),m=n(48372);const p=JSON.parse('{"text_external-consumption":"External Consumption","text_allocator-caches":"Allocator Caches","text_shared-cache":"Shared Cache","text_memtable":"MemTable","text_query-execution":"Query Execution","text_usage":"Usage","text_soft-limit":"Soft Limit","text_hard-limit":"Hard Limit","text_other":"Other"}'),h=(0,m.g4)("ydb-memory-viewer",{en:p});function g(e){return(0,d.kf)(e)?parseFloat(String(e)):void 0}var v=n(60712);const f=1,S=.01*i.J7,k=(0,r.cn)("memory-viewer"),y=(e,t)=>[(0,a.z3)({value:e,size:"gb",withSizeLabel:!1,precision:2}),(0,a.z3)({value:t,size:"gb",withSizeLabel:!0,precision:1})];function b({stats:e,percents:t,formatValues:n,className:r,warningThreshold:i,dangerThreshold:m}){var p;const b=null!==(p=e.AnonRss)&&void 0!==p?p:function(e){const t=g(e.AllocatedMemory)||0,n=g(e.AllocatorCachesMemory)||0;return String(t+n)}(e),N=e.HardLimit,D=(0,s.D)();let x=Math.floor(parseFloat(String(b))/parseFloat(String(N))*100)||0;x=x>100?100:x;let w=b,I=N,C="/";t?(w=x+"%",I="",C=""):n&&([w,I]=n(Number(b),Number(N)));const P=function(e,t){const n=[{label:h("text_shared-cache"),key:"SharedCacheConsumption",value:g(e.SharedCacheConsumption),capacity:g(e.SharedCacheLimit),isInfo:!1},{label:h("text_query-execution"),key:"QueryExecutionConsumption",value:g(e.QueryExecutionConsumption),capacity:g(e.QueryExecutionLimit),isInfo:!1},{label:h("text_memtable"),key:"MemTableConsumption",value:g(e.MemTableConsumption),capacity:g(e.MemTableLimit),isInfo:!1},{label:h("text_allocator-caches"),key:"AllocatorCachesMemory",value:g(e.AllocatorCachesMemory),isInfo:!1}],s=n.filter((e=>void 0!==e.value)).reduce(((e,t)=>e+t.value),0),o=Math.max(0,t-s);return n.push({label:h("text_other"),key:"Other",value:o,isInfo:!1}),n.push({label:h("text_external-consumption"),key:"ExternalConsumption",value:g(e.ExternalConsumption),isInfo:!0},{label:h("text_usage"),key:"Usage",value:t,isInfo:!0},{label:h("text_soft-limit"),key:"SoftLimit",value:g(e.SoftLimit),isInfo:!0},{label:h("text_hard-limit"),key:"HardLimit",value:g(e.HardLimit),isInfo:!0}),n.filter((e=>void 0!==e.value))}(e,Number(b)),j=(0,l.w)({fillWidth:x,warningThreshold:i,dangerThreshold:m,colorizeProgress:!0});let E=0;return(0,v.jsx)(u.P,{renderPopupContent:()=>(0,v.jsx)(o.u,{responsive:!0,children:P.map((({label:e,value:t,capacity:n,key:s})=>(0,v.jsx)(o.u.Item,{name:(0,v.jsxs)("div",{className:k("container"),children:[(0,v.jsx)("div",{className:k("legend",{type:s})}),(0,v.jsx)("div",{className:k("name"),children:e})]}),children:n?(0,v.jsx)(c.O,{value:t,capacity:n,formatValues:y,colorizeProgress:!0}):(0,a.z3)({value:t,size:"gb",withSizeLabel:!0,precision:2})},e)))}),children:(0,v.jsx)("div",{className:k({theme:D,status:j},r),children:(0,v.jsxs)("div",{className:k("progress-container"),children:[P.filter((({isInfo:e})=>!e)).map((e=>{if(e.value{n.d(t,{J:()=>re,k:()=>ae});var s=n(79879),o=n(4557),a=n(63291),r=n(47665),i=n(84375),l=n(99991),d=n(71661),u=n(10508),c=n(33775),m=n(13342),p=n(92459),h=n(7435),g=n(77506),v=n(76086),f=n(56839),S=n(16439),k=n(73891),y=n(41650),b=n(59284),N=n(69033),D=n(87184),x=n(8809),w=n(10576),I=n(156),C=n(60712);const P=(0,g.cn)("ydb-storage-disks");function j({vDisks:e=[],viewContext:t,erasure:n}){const[s,o]=b.useState(),a=(0,I.Ep)(e,n),{theme:{spaceBaseSize:r}}=(0,N.L)();if(!e.length)return null;const i=(300-r*(e.length-1))/e.length;return(0,C.jsxs)("div",{className:P(null),children:[(0,C.jsx)(D.s,{direction:"row",gap:1,grow:!0,style:{width:300},children:null===e||void 0===e?void 0:e.map(((e,n)=>(0,C.jsx)(E,{vDisk:e,inactive:!(0,I.OH)(e,t),highlightedVDisk:s,setHighlightedVDisk:o,unavailableVDiskWidth:i},e.StringifiedId||n)))}),(0,C.jsx)("div",{className:P("pdisks-wrapper"),children:null===e||void 0===e?void 0:e.map(((e,t)=>{var n;return(0,C.jsx)(A,{vDisk:e,highlightedVDisk:s,setHighlightedVDisk:o,withDCMargin:a.includes(t)},(null===e||void 0===e||null===(n=e.PDisk)||void 0===n?void 0:n.StringifiedId)||t)}))})]})}function E({vDisk:e,highlightedVDisk:t,inactive:n,setHighlightedVDisk:s,unavailableVDiskWidth:o}){const a={...e,PDisk:void 0},r=e.StringifiedId,i=(0,y.kf)(a.AllocatedSize)?void 0:o,l=Number(a.AllocatedSize)||1;return(0,C.jsx)("div",{style:{flexGrow:l,minWidth:i},className:P("vdisk-item"),children:(0,C.jsx)(x.y,{data:a,compact:!0,inactive:n,showPopup:t===r,onShowPopup:()=>s(r),onHidePopup:()=>s(void 0),progressBarClassName:P("vdisk-progress-bar")})})}function A({vDisk:e,highlightedVDisk:t,setHighlightedVDisk:n,withDCMargin:s}){const o=e.StringifiedId;return e.PDisk?(0,C.jsx)(w.E,{className:P("pdisk-item",{"with-dc-margin":s}),progressBarClassName:P("pdisk-progress-bar"),data:e.PDisk,showPopup:t===o,onShowPopup:()=>n(o),onHidePopup:()=>n(void 0)}):null}var T=n(7187);const U="--ydb-stack-level",R=(0,g.cn)("stack"),G=({children:e,className:t})=>(0,C.jsx)("div",{className:R(null,t),children:b.Children.map(e,((e,t)=>b.isValidElement(e)?(0,C.jsx)("div",{className:R("layer"),style:{[U]:t},children:e}):null))});function M({data:e,className:t,stackClassName:n,...s}){const{Donors:o,...a}=e||{},r=o&&o.length>0?(0,C.jsxs)(G,{className:n,children:[(0,C.jsx)(x.y,{data:a,...s}),o.map((e=>{const t=(0,T.NJ)(e);return(0,C.jsx)(x.y,{data:e,...s},(0,f.U9)(t?e.VDiskId:e))}))]}):(0,C.jsx)(x.y,{data:e,...s});return(0,C.jsx)("div",{className:t,children:r})}const L=(0,g.cn)("ydb-storage-vdisks");function z({vDisks:e,viewContext:t,erasure:n}){const s=(0,I.Ep)(e,n);return(0,C.jsx)("div",{className:L("wrapper"),children:null===e||void 0===e?void 0:e.map(((e,n)=>(0,C.jsx)(M,{data:e,inactive:!(0,I.OH)(e,t),className:L("item",{"with-dc-margin":s.includes(n)})},e.StringifiedId)))})}var V=n(91157),W=n(74319);const F=(0,g.cn)("ydb-storage-groups-columns"),O={name:W.UW.PoolName,header:W.H6.PoolName,width:250,render:({row:e})=>e.PoolName?(0,C.jsx)(d.s,{content:e.PoolName,placement:["right"],behavior:a.m.Immediate,className:F("pool-name-wrapper"),children:(0,C.jsx)("span",{className:F("pool-name"),children:e.PoolName})}):v.Pd,align:o.Ay.LEFT},H={name:W.UW.MediaType,header:W.H6.MediaType,width:100,resizeMinWidth:100,align:o.Ay.LEFT,render:({row:e})=>(0,C.jsxs)("div",{children:[(0,C.jsx)(r.J,{children:e.MediaType||"\u2014"}),"\xa0",e.Encryption&&(0,C.jsx)(i.A,{content:(0,V.A)("encrypted"),placement:"right",behavior:a.m.Immediate,children:(0,C.jsx)(r.J,{children:(0,C.jsx)(l.I,{data:s.A,size:18})})})]}),sortable:!1},_={name:W.UW.Erasure,header:W.H6.Erasure,width:100,sortAccessor:e=>e.ErasureSpecies,render:({row:e})=>e.ErasureSpecies?e.ErasureSpecies:"-",align:o.Ay.LEFT},B={name:W.UW.Degraded,header:W.H6.Degraded,width:110,resizeMinWidth:110,render:({row:e})=>e.Degraded?(0,C.jsxs)(r.J,{theme:(0,I.k_)(e),children:["Degraded: ",e.Degraded]}):"-",align:o.Ay.LEFT,defaultOrder:o.Ay.DESCENDING},$={name:W.UW.State,header:W.H6.State,width:150,render:({row:e})=>{var t;return null!==(t=e.State)&&void 0!==t?t:v.Pd},align:o.Ay.LEFT,defaultOrder:o.Ay.DESCENDING},Y={name:W.UW.Usage,header:W.H6.Usage,width:85,resizeMinWidth:75,render:({row:e})=>(0,h.f8)(e.Usage)?(0,C.jsx)(m.U,{value:Math.floor(e.Usage),theme:(0,S.f)(e.Usage)}):v.Pd,align:o.Ay.LEFT},K={name:W.UW.DiskSpaceUsage,header:W.H6.DiskSpaceUsage,width:115,resizeMinWidth:75,render:({row:e})=>(0,h.f8)(e.DiskSpaceUsage)?(0,C.jsx)(m.U,{value:Math.floor(e.DiskSpaceUsage),theme:(0,S.f)(e.DiskSpaceUsage)}):v.Pd,align:o.Ay.LEFT},J={name:W.UW.GroupId,header:W.H6.GroupId,width:140,render:({row:e})=>e.GroupId?(0,C.jsx)(u.c,{name:String(e.GroupId),path:(0,p._g)(e.GroupId),hasClipboardButton:!0,showStatus:!1}):"-",sortAccessor:e=>Number(e.GroupId),align:o.Ay.LEFT},Q={name:W.UW.Used,header:W.H6.Used,width:100,render:({row:e})=>(0,y.wb)(e.Used,!0),align:o.Ay.RIGHT},X={name:W.UW.Limit,header:W.H6.Limit,width:100,render:({row:e})=>(0,y.wb)(e.Limit),align:o.Ay.RIGHT},q={name:W.UW.DiskSpace,header:W.H6.DiskSpace,width:70,render:({row:e})=>(0,C.jsx)(c.k,{status:e.DiskSpace}),align:o.Ay.CENTER},Z={name:W.UW.Read,header:W.H6.Read,width:100,render:({row:e})=>e.Read?(0,y.O4)(e.Read):"-",align:o.Ay.RIGHT},ee={name:W.UW.Write,header:W.H6.Write,width:100,render:({row:e})=>e.Write?(0,y.O4)(e.Write):"-",align:o.Ay.RIGHT},te={name:W.UW.Latency,header:W.H6.Latency,width:100,render:({row:e})=>(0,h.f8)(e.LatencyPutTabletLogMs)?(0,k.Xo)(e.LatencyPutTabletLogMs):v.Pd,align:o.Ay.RIGHT},ne={name:W.UW.AllocationUnits,header:W.H6.AllocationUnits,width:150,render:({row:e})=>(0,h.f8)(e.AllocationUnits)?(0,f.ZV)(e.AllocationUnits):v.Pd,align:o.Ay.RIGHT},se=e=>({name:W.UW.VDisks,header:W.H6.VDisks,className:F("vdisks-column"),render:({row:t})=>(0,C.jsx)(z,{vDisks:t.VDisks,viewContext:null===e||void 0===e?void 0:e.viewContext,erasure:t.ErasureSpecies}),align:o.Ay.CENTER,width:780,resizeable:!1,sortable:!1}),oe=e=>({name:W.UW.VDisksPDisks,header:W.H6.VDisksPDisks,className:F("disks-column"),render:({row:t})=>(0,C.jsx)(j,{vDisks:t.VDisks,viewContext:null===e||void 0===e?void 0:e.viewContext,erasure:t.ErasureSpecies}),align:o.Ay.CENTER,width:900,resizeable:!1,sortable:!1}),ae=()=>[J,H,_,Y,Q,X],re=e=>[J,O,H,_,B,$,Y,K,Q,X,q,Z,ee,te,ne,se(e),oe(e)].map((e=>({...e,sortable:(0,W.i4)(e.name)})))},74319:(e,t,n)=>{n.d(t,{hu:()=>m,YX:()=>k,LO:()=>p,UW:()=>d,H6:()=>h,qK:()=>i,SE:()=>f,zY:()=>l,GP:()=>b,Ai:()=>c,i4:()=>N,kY:()=>S});var s=n(370),o=n(48372);const a=JSON.parse('{"pool-name":"Pool Name","type":"Type","encryption":"Encryption","erasure":"Erasure","degraded":"Degraded","missing-disks":"Missing Disks","state":"State","usage":"Usage","disk-usage":"Disk usage","group-id":"Group ID","used":"Used","limit":"Limit","space":"Space","read":"Read","write":"Write","latency":"Latency","allocation-units":"Allocation Units","vdisks":"VDisks","vdisks-pdisks":"VDisks with PDisks"}'),r=(0,o.g4)("ydb-storage-groups-columns",{en:a}),i="storageGroupsColumnsWidth",l="storageGroupsSelectedColumns",d={GroupId:"GroupId",PoolName:"PoolName",MediaType:"MediaType",Erasure:"Erasure",Used:"Used",Limit:"Limit",Usage:"Usage",DiskSpaceUsage:"DiskSpaceUsage",DiskSpace:"DiskSpace",Read:"Read",Write:"Write",Latency:"Latency",AllocationUnits:"AllocationUnits",VDisks:"VDisks",VDisksPDisks:"VDisksPDisks",Degraded:"Degraded",State:"State"},u=["DiskSpaceUsage","Latency","AllocationUnits","VDisksPDisks"];function c(e){return u.includes(e)}const m=["GroupId","PoolName","Erasure","Used","VDisks"],p=["GroupId"],h={get PoolName(){return r("pool-name")},get MediaType(){return r("type")},get Erasure(){return r("erasure")},get GroupId(){return r("group-id")},get Used(){return r("used")},get Limit(){return r("limit")},get Usage(){return r("usage")},get DiskSpaceUsage(){return r("disk-usage")},get DiskSpace(){return r("space")},get Read(){return r("read")},get Write(){return r("write")},get Latency(){return r("latency")},get AllocationUnits(){return r("allocation-units")},get VDisks(){return r("vdisks")},get VDisksPDisks(){return r("vdisks-pdisks")},get Degraded(){return r("missing-disks")},get State(){return r("state")}},g={get GroupId(){return r("group-id")},get Erasure(){return r("erasure")},get Usage(){return r("usage")},get DiskSpaceUsage(){return r("disk-usage")},get PoolName(){return r("pool-name")},get Kind(){return r("type")},get Encryption(){return r("encryption")},get MediaType(){return r("type")},get MissingDisks(){return r("missing-disks")},get State(){return r("state")},get Latency(){return r("latency")}},v=["PoolName","MediaType","Encryption","Erasure","Usage","DiskSpaceUsage","State","MissingDisks","Latency"],f=v.map((e=>({value:e,content:g[e]}))),S=s.z.custom((e=>v.includes(e))).catch(void 0),k={GroupId:["GroupId"],PoolName:["PoolName"],MediaType:["MediaType","Encryption"],Erasure:["Erasure"],Used:["Used"],Limit:["Limit"],Usage:["Usage"],DiskSpaceUsage:["DiskSpaceUsage"],DiskSpace:["State"],Read:["Read"],Write:["Write"],Latency:["Latency"],AllocationUnits:["AllocationUnits"],VDisks:["VDisk","PDisk","Read","Write"],VDisksPDisks:["VDisk","PDisk","Read","Write"],Degraded:["MissingDisks"],State:["State"]},y={GroupId:"GroupId",PoolName:"PoolName",MediaType:"MediaType",Erasure:"Erasure",Used:"Used",Limit:"Limit",Usage:"Usage",DiskSpaceUsage:"DiskSpaceUsage",DiskSpace:void 0,Read:"Read",Write:"Write",Latency:"Latency",AllocationUnits:"AllocationUnits",VDisks:void 0,VDisksPDisks:void 0,Degraded:"Degraded",State:"State"};function b(e){return y[e]}function N(e){return Boolean(b(e))}},78461:(e,t,n)=>{n.d(t,{Y:()=>o});const s={HDD:"HDD",SSD:"SSD",MVME:"NVME"};function o(e){if(!e)return;const t=function(e,t){const n={};return Object.entries(t).reduce(((t,[s,o])=>{const a=e.length-t,r=a-o;return n[s]=e.substring(r,a)||"0",t+o}),0),n}(BigInt(e).toString(2),{isSolidState:1,kind:55,typeExt:8});if("1"===t.isSolidState)switch(parseInt(t.typeExt,2)){case 0:return s.SSD;case 2:return s.MVME}else if("0"===t.typeExt)return s.HDD}},78762:(e,t,n)=>{n.d(t,{pt:()=>ne,SH:()=>X,fr:()=>_,uk:()=>L,Bg:()=>Y,Nh:()=>G,ID:()=>B,fR:()=>$,iX:()=>O,Vz:()=>Q,H:()=>q,_E:()=>R,eT:()=>M,wN:()=>te,kv:()=>H,pH:()=>F,OX:()=>z,ui:()=>ee,DH:()=>Z,oz:()=>K,qp:()=>J,jl:()=>W,Rn:()=>V});var s=n(4557),o=n(23900),a=n(7435),r=n(77506),i=n(76086),l=n(56839),d=n(16439),u=n(41650),c=n(71661),m=n(73473),p=n(29819),h=n(31684),g=n(78034),v=n(10508),f=n(80176),S=n(60712);const k=({node:e,getNodeRef:t,database:n,statusForIcon:s})=>{if(!e.Host)return(0,S.jsx)("span",{children:"\u2014"});const o="ConnectStatus"===s?e.ConnectStatus:e.SystemState,a=!(0,g.X7)(e);let r;if(t){const n=t(e);r=n?(0,h.Un)(n):void 0}else if(e.NodeId){const t=(0,h.Kx)(e.NodeId);r=(0,h.Un)(t)}const i=a?(0,p.vI)(e.NodeId,{database:null!==n&&void 0!==n?n:e.TenantName},e.TenantName?"tablets":"storage"):void 0;return(0,S.jsx)(v.c,{name:e.Host,status:o,path:i,hasClipboardButton:!0,infoPopoverContent:a?(0,S.jsx)(f.p,{data:e,nodeHref:r}):null})};var y=n(48295),b=n(15132),N=n(52905),D=n(58267);const x=(0,r.cn)("tablets-statistic"),w=({tablets:e=[],database:t,nodeId:n})=>{const s=(e=>e.map((e=>({label:(0,i.bk)(e.Type),type:e.Type,count:e.Count,state:(0,D.P)(e.State)}))).sort(((e,t)=>String(e.label).localeCompare(String(t.label)))))(e);return(0,S.jsx)("div",{className:x(),children:s.map(((e,s)=>{var o;const a=(0,p.vI)(n,{database:t},"tablets"),r=`${e.label}: ${e.count}`,i=x("tablet",{state:null===(o=e.state)||void 0===o?void 0:o.toLowerCase()});return(0,S.jsx)(N.N_,{to:a,className:i,children:r},s)}))})};var I=n(41826),C=n(13342),P=n(86782),j=n(31911),E=n(73891);function A(e){return(0,E.Xo)((0,E.Jc)(e,1))}function T(e){const t=(0,E.Jc)(e,1);return(Number(t)<=0?"":"+")+(0,E.Xo)(t)}const U=(0,r.cn)("ydb-nodes-columns");function R(){return{name:P.vg.NodeId,header:"#",width:80,resizeMinWidth:80,render:({row:e})=>e.NodeId,align:s.Ay.RIGHT}}function G({getNodeRef:e,database:t},{statusForIcon:n="SystemState"}={}){return{name:P.vg.Host,header:P.uG.Host,render:({row:s})=>(0,S.jsx)(k,{node:s,getNodeRef:e,database:t,statusForIcon:n}),width:350,align:s.Ay.LEFT}}function M(){return{name:P.vg.NodeName,header:P.uG.NodeName,align:s.Ay.LEFT,render:({row:e})=>e.NodeName||i.Pd,width:200}}function L(){return{name:P.vg.DC,header:P.uG.DC,align:s.Ay.LEFT,render:({row:e})=>e.DC||i.Pd,width:60}}function z(){return{name:P.vg.Rack,header:P.uG.Rack,align:s.Ay.LEFT,render:({row:e})=>e.Rack||i.Pd,width:100}}function V(){return{name:P.vg.Version,header:P.uG.Version,width:200,align:s.Ay.LEFT,render:({row:e})=>(0,S.jsx)(c.s,{content:e.Version,children:e.Version})}}function W(){return{name:P.vg.Uptime,header:P.uG.Uptime,sortAccessor:({StartTime:e})=>e?-e:0,render:({row:e})=>(0,S.jsx)(I.p,{StartTime:e.StartTime,DisconnectTime:e.DisconnectTime}),align:s.Ay.RIGHT,width:120}}function F(){return{name:P.vg.RAM,header:P.uG.RAM,sortAccessor:({MemoryUsed:e=0})=>Number(e),defaultOrder:s.Ay.DESCENDING,render:({row:e})=>{const[t,n]=(0,u.kf)(e.MemoryUsed)&&(0,u.kf)(e.MemoryLimit)?(0,l.j9)(Number(e.MemoryUsed),Number(e.MemoryLimit),"gb",void 0,!0):[0,0];return(0,S.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,S.jsxs)(o.u,{responsive:!0,children:[(0,S.jsx)(o.u.Item,{name:(0,j.A)("field_memory-used"),children:t}),(0,S.jsx)(o.u.Item,{name:(0,j.A)("field_memory-limit"),children:n})]}),children:(0,S.jsx)(b.O,{value:e.MemoryUsed,capacity:e.MemoryLimit,formatValues:(e,t)=>(0,l.j9)(e,t,"gb",void 0,!0),className:U("column-ram"),colorizeProgress:!0,hideCapacity:!0})})},align:s.Ay.LEFT,width:80,resizeMinWidth:40}}function O(){return{name:P.vg.Memory,header:P.uG.Memory,defaultOrder:s.Ay.DESCENDING,render:({row:e})=>e.MemoryStats?(0,S.jsx)(m.S,{formatValues:l.vX,stats:e.MemoryStats}):(0,S.jsx)(b.O,{value:e.MemoryUsed,capacity:e.MemoryLimit,formatValues:l.vX,colorizeProgress:!0}),align:s.Ay.LEFT,width:300,resizeMinWidth:170}}function H(){return{name:P.vg.Pools,header:P.uG.Pools,sortAccessor:({PoolStats:e=[]})=>Math.max(...e.map((({Usage:e})=>Number(e)))),defaultOrder:s.Ay.DESCENDING,render:({row:e})=>e.PoolStats?(0,S.jsx)(y._,{pools:e.PoolStats}):i.Pd,align:s.Ay.LEFT,width:80,resizeMinWidth:60}}function _(){return{name:P.vg.CPU,header:P.uG.CPU,sortAccessor:({PoolStats:e=[]})=>Math.max(...e.map((({Usage:e})=>Number(e)))),defaultOrder:s.Ay.DESCENDING,render:({row:e})=>{if(!e.PoolStats)return i.Pd;let t=(0,u.kf)(e.CoresUsed)&&(0,u.kf)(e.CoresTotal)?e.CoresUsed/e.CoresTotal:void 0;if(void 0===t){let n=0;t=e.PoolStats.reduce(((e,t)=>(n+=Number(t.Threads),e+Number(t.Usage)*Number(t.Threads))),0),t/=n}return(0,S.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,S.jsx)(o.u,{responsive:!0,children:e.PoolStats.map((e=>(0,u.kf)(e.Usage)?(0,S.jsx)(o.u.Item,{name:e.Name,children:(0,f.Qz)("Usage",e.Usage).value},e.Name):null))}),children:(0,S.jsx)(b.O,{className:U("column-cpu"),value:t,capacity:1,colorizeProgress:!0,percents:!0})})},align:s.Ay.LEFT,width:80,resizeMinWidth:40}}function B(){return{name:P.vg.LoadAverage,header:P.uG.LoadAverage,sortAccessor:({LoadAveragePercents:e=[]})=>e[0],defaultOrder:s.Ay.DESCENDING,render:({row:e})=>(0,S.jsx)(b.O,{value:e.LoadAveragePercents&&e.LoadAveragePercents.length>0?e.LoadAveragePercents[0]:void 0,percents:!0,colorizeProgress:!0,capacity:100}),align:s.Ay.LEFT,width:170,resizeMinWidth:170}}function $(){return{name:P.vg.Load,header:P.uG.Load,sortAccessor:({LoadAveragePercents:e=[]})=>e[0],defaultOrder:s.Ay.DESCENDING,render:({row:e})=>e.LoadAveragePercents&&e.LoadAveragePercents.length>0?(0,S.jsx)(C.U,{value:e.LoadAveragePercents[0].toFixed(),theme:(0,d.f)(e.LoadAveragePercents[0])}):i.Pd,align:s.Ay.LEFT,width:80,resizeMinWidth:70}}function Y(){return{name:P.vg.DiskSpaceUsage,header:P.uG.DiskSpaceUsage,render:({row:e})=>(0,a.f8)(e.DiskSpaceUsage)?(0,S.jsx)(C.U,{value:Math.floor(e.DiskSpaceUsage),theme:(0,d.f)(e.DiskSpaceUsage)}):i.Pd,align:s.Ay.LEFT,width:115,resizeMinWidth:75}}function K(){return{name:P.vg.TotalSessions,header:P.uG.TotalSessions,render:({row:e})=>{var t;return null!==(t=e.TotalSessions)&&void 0!==t?t:i.Pd},align:s.Ay.RIGHT,width:100}}function J({database:e}){return{name:P.vg.Tablets,header:P.uG.Tablets,width:500,resizeMinWidth:500,render:({row:t})=>t.Tablets?(0,S.jsx)(w,{database:null!==e&&void 0!==e?e:t.TenantName,nodeId:t.NodeId,tablets:t.Tablets}):i.Pd,align:s.Ay.LEFT,sortable:!1}}function Q(){return{name:P.vg.Missing,header:P.uG.Missing,render:({row:e})=>e.Missing,align:s.Ay.CENTER,defaultOrder:s.Ay.DESCENDING,width:100}}function X(){return{name:P.vg.Connections,header:P.uG.Connections,render:({row:e})=>(0,u.kf)(e.Connections)?e.Connections:i.Pd,align:s.Ay.RIGHT,width:130}}function q(){return{name:P.vg.NetworkUtilization,header:P.uG.NetworkUtilization,render:({row:e})=>{const{NetworkUtilization:t,NetworkUtilizationMin:n=0,NetworkUtilizationMax:s=0}=e;return(0,u.kf)(t)?(0,S.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,S.jsxs)(o.u,{responsive:!0,children:[(0,S.jsx)(o.u.Item,{name:(0,j.A)("sum"),children:(0,l.l9)(t)},"NetworkUtilization"),(0,S.jsx)(o.u.Item,{name:(0,j.A)("min"),children:(0,l.l9)(n)},"NetworkUtilizationMin"),(0,S.jsx)(o.u.Item,{name:(0,j.A)("max"),children:(0,l.l9)(s)},"NetworkUtilizationMax")]}),children:(0,l.l9)(t)}):i.Pd},align:s.Ay.RIGHT,width:110}}function Z(){return{name:P.vg.SendThroughput,header:P.uG.SendThroughput,render:({row:e})=>(0,u.kf)(e.SendThroughput)?(0,u.O4)(e.SendThroughput):i.Pd,align:s.Ay.RIGHT,width:110}}function ee(){return{name:P.vg.ReceiveThroughput,header:P.uG.ReceiveThroughput,render:({row:e})=>(0,u.kf)(e.ReceiveThroughput)?(0,u.O4)(e.ReceiveThroughput):i.Pd,align:s.Ay.RIGHT,width:110}}function te(){return{name:P.vg.PingTime,header:P.uG.PingTime,render:({row:e})=>{const{PingTimeUs:t,PingTimeMinUs:n=0,PingTimeMaxUs:s=0}=e;return(0,u.kf)(t)?(0,S.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,S.jsxs)(o.u,{responsive:!0,children:[(0,S.jsx)(o.u.Item,{name:(0,j.A)("avg"),children:A(t)},"PingTimeUs"),(0,S.jsx)(o.u.Item,{name:(0,j.A)("min"),children:A(n)},"PingTimeMinUs"),(0,S.jsx)(o.u.Item,{name:(0,j.A)("max"),children:A(s)},"PingTimeMaxUs")]}),children:A(t)}):i.Pd},align:s.Ay.RIGHT,width:110}}function ne(){return{name:P.vg.ClockSkew,header:P.uG.ClockSkew,render:({row:e})=>{const{ClockSkewUs:t,ClockSkewMinUs:n=0,ClockSkewMaxUs:s=0}=e;return(0,u.kf)(t)?(0,S.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,S.jsxs)(o.u,{responsive:!0,children:[(0,S.jsx)(o.u.Item,{name:(0,j.A)("avg"),children:T(t)},"ClockSkewUs"),(0,S.jsx)(o.u.Item,{name:(0,j.A)("min"),children:T(n)},"ClockSkewMinUs"),(0,S.jsx)(o.u.Item,{name:(0,j.A)("max"),children:T(s)},"ClockSkewMaxUs")]}),children:T(t)}):i.Pd},align:s.Ay.RIGHT,width:110}}},81101:(e,t,n)=>{n.d(t,{$:()=>r});var s=n(59109),o=n(44508),a=n(60712);const r=e=>403===e.status?(0,a.jsx)(s.O,{position:"left"}):(0,a.jsx)(o.o,{error:e})},86782:(e,t,n)=>{n.d(t,{fN:()=>c,kU:()=>p,kn:()=>u,sp:()=>h,uG:()=>l,vg:()=>a,xd:()=>i,zO:()=>o});var s=n(31911);const o="nodesTableColumnsWidth",a={NodeId:"NodeId",Host:"Host",Database:"Database",NodeName:"NodeName",DC:"DC",Rack:"Rack",Version:"Version",Uptime:"Uptime",Memory:"Memory",RAM:"RAM",CPU:"CPU",Pools:"Pools",LoadAverage:"LoadAverage",Load:"Load",DiskSpaceUsage:"DiskSpaceUsage",TotalSessions:"TotalSessions",Connections:"Connections",NetworkUtilization:"NetworkUtilization",SendThroughput:"SendThroughput",ReceiveThroughput:"ReceiveThroughput",PingTime:"PingTime",ClockSkew:"ClockSkew",Missing:"Missing",Tablets:"Tablets",PDisks:"PDisks"},r=["Pools","Memory"];function i(e){return r.includes(e)}const l={get NodeId(){return(0,s.A)("node-id")},get Host(){return(0,s.A)("host")},get Database(){return(0,s.A)("database")},get NodeName(){return(0,s.A)("node-name")},get DC(){return(0,s.A)("dc")},get Rack(){return(0,s.A)("rack")},get Version(){return(0,s.A)("version")},get Uptime(){return(0,s.A)("uptime")},get Memory(){return(0,s.A)("memory")},get RAM(){return(0,s.A)("ram")},get Pools(){return(0,s.A)("pools")},get CPU(){return(0,s.A)("cpu")},get LoadAverage(){return(0,s.A)("load-average")},get Load(){return(0,s.A)("load")},get DiskSpaceUsage(){return(0,s.A)("disk-usage")},get TotalSessions(){return(0,s.A)("sessions")},get Connections(){return(0,s.A)("connections")},get NetworkUtilization(){return(0,s.A)("utilization")},get SendThroughput(){return(0,s.A)("send")},get ReceiveThroughput(){return(0,s.A)("receive")},get PingTime(){return(0,s.A)("ping")},get ClockSkew(){return(0,s.A)("skew")},get Missing(){return(0,s.A)("missing")},get Tablets(){return(0,s.A)("tablets")},get PDisks(){return(0,s.A)("pdisks")}},d={get NodeId(){return(0,s.A)("node-id")},get Host(){return(0,s.A)("host")},get NodeName(){return(0,s.A)("node-name")},get Database(){return(0,s.A)("database")},get DiskSpaceUsage(){return(0,s.A)("disk-usage")},get DC(){return(0,s.A)("dc")},get Rack(){return(0,s.A)("rack")},get Missing(){return(0,s.A)("missing")},get Uptime(){return(0,s.A)("uptime")},get Version(){return(0,s.A)("version")},get SystemState(){return(0,s.A)("system-state")},get ConnectStatus(){return(0,s.A)("connect-status")},get NetworkUtilization(){return(0,s.A)("network-utilization")},get ClockSkew(){return(0,s.A)("clock-skew")},get PingTime(){return(0,s.A)("ping-time")}};function u(e){return d[e]}const c={NodeId:["NodeId"],Host:["Host","Rack","Database","SystemState"],Database:["Database"],NodeName:["NodeName"],DC:["DC"],Rack:["Rack"],Version:["Version"],Uptime:["Uptime","DisconnectTime"],Memory:["Memory","MemoryDetailed"],RAM:["Memory"],Pools:["CPU"],CPU:["CPU"],LoadAverage:["LoadAverage"],Load:["LoadAverage"],DiskSpaceUsage:["DiskSpaceUsage"],TotalSessions:["SystemState"],Connections:["Connections"],NetworkUtilization:["NetworkUtilization"],SendThroughput:["SendThroughput"],ReceiveThroughput:["ReceiveThroughput"],PingTime:["PingTime"],ClockSkew:["ClockSkew"],Missing:["Missing"],Tablets:["Tablets","Database"],PDisks:["PDisks"]},m={NodeId:"NodeId",Host:"Host",Database:"Database",NodeName:"NodeName",DC:"DC",Rack:"Rack",Version:"Version",Uptime:"Uptime",Memory:"Memory",RAM:"Memory",CPU:"CPU",Pools:"CPU",LoadAverage:"LoadAverage",Load:"LoadAverage",DiskSpaceUsage:"DiskSpaceUsage",TotalSessions:void 0,Connections:"Connections",NetworkUtilization:"NetworkUtilization",SendThroughput:"SendThroughput",ReceiveThroughput:"ReceiveThroughput",PingTime:"PingTime",ClockSkew:"ClockSkew",Missing:"Missing",Tablets:void 0,PDisks:void 0};function p(e){return m[e]}function h(e){return Boolean(p(e))}},88226:(e,t,n)=>{n.d(t,{V:()=>d});n(59284);var s=n(77506),o=n(76086),a=n(7187),r=n(90182),i=n(60712);const l=(0,s.cn)("storage-disk-progress-bar");function d({diskAllocatedPercent:e=-1,severity:t,compact:n,faded:s,inactive:d,empty:u,content:c,className:m}){const[p]=(0,r.iK)(o.TJ),h={inverted:p,compact:n,faded:s,empty:u,inactive:d},g=void 0!==t&&(0,a.XY)(t);g&&(h[g.toLocaleLowerCase()]=!0);return(0,i.jsxs)("div",{className:l(h,m),role:"meter","aria-label":"Disk allocated space","aria-valuemin":0,"aria-valuemax":100,"aria-valuenow":e,children:[(()=>{if(n)return(0,i.jsx)("div",{className:l("fill-bar",h),style:{width:"100%"}});const t=p?100-e:e;return e>=0?(0,i.jsx)("div",{className:l("fill-bar",h),style:{width:`${t}%`}}):null})(),c||(!n&&e>=0?(0,i.jsx)("div",{className:l("title"),children:`${Math.floor(e)}%`}):null)]})}},90053:(e,t,n)=>{n.d(t,{E:()=>h});var s=n(8873),o=n(84476),a=n(24555),r=n(21334),i=n(77506),l=n(90182),d=n(48372);const u=JSON.parse('{"None":"None","15 sec":"15 sec","1 min":"1 min","2 min":"2 min","5 min":"5 min","Refresh":"Refresh"}'),c=(0,d.g4)("ydb-diagnostics-autorefresh-control",{en:u});var m=n(60712);const p=(0,i.cn)("auto-refresh-control");function h({className:e,onManualRefresh:t}){const n=(0,l.YQ)(),[i,d]=(0,l.Nt)();return(0,m.jsxs)("div",{className:p(null,e),children:[(0,m.jsx)(o.$,{view:"flat-secondary",onClick:()=>{n(r.F.util.invalidateTags(["All"])),null===t||void 0===t||t()},extraProps:{"aria-label":c("Refresh")},children:(0,m.jsx)(o.$.Icon,{children:(0,m.jsx)(s.A,{})})}),(0,m.jsxs)(a.l,{value:[String(i)],onUpdate:e=>{d(Number(e))},width:85,qa:"ydb-autorefresh-select",children:[(0,m.jsx)(a.l.Option,{value:"0",children:c("None")}),(0,m.jsx)(a.l.Option,{value:"15000",children:c("15 sec")}),(0,m.jsx)(a.l.Option,{value:"60000",children:c("1 min")}),(0,m.jsx)(a.l.Option,{value:"120000",children:c("2 min")}),(0,m.jsx)(a.l.Option,{value:"300000",children:c("5 min")})]})]})}},91157:(e,t,n)=>{n.d(t,{A:()=>r});var s=n(48372);const o=JSON.parse('{"empty.default":"No such groups","empty.out_of_space":"No groups with out of space errors","empty.degraded":"No degraded groups","show_all":"Show all groups","encrypted":"Encrypted group"}'),a=JSON.parse('{"empty.default":"\u041d\u0435\u0442 \u0433\u0440\u0443\u043f\u043f","empty.out_of_space":"\u041d\u0435\u0442 \u0433\u0440\u0443\u043f\u043f, \u0432 \u043a\u043e\u0442\u043e\u0440\u044b\u0445 \u043a\u043e\u043d\u0447\u0430\u0435\u0442\u0441\u044f \u043c\u0435\u0441\u0442\u043e","empty.degraded":"\u041d\u0435\u0442 \u0434\u0435\u0433\u0440\u0430\u0434\u0438\u0440\u043e\u0432\u0430\u0432\u0448\u0438\u0445 \u0433\u0440\u0443\u043f\u043f","show_all":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435 \u0433\u0440\u0443\u043f\u043f\u044b","encrypted":"\u0417\u0430\u0448\u0438\u0444\u0440\u043e\u0432\u0430\u043d\u043d\u0430\u044f \u0433\u0440\u0443\u043f\u043f\u0430"}'),r=(0,s.g4)("ydb-storage-groups",{ru:a,en:o})},94025:(e,t,n)=>{n.d(t,{t:()=>s});let s=function(e){return e.Initial="Initial",e.InitialFormatRead="InitialFormatRead",e.InitialFormatReadError="InitialFormatReadError",e.InitialSysLogRead="InitialSysLogRead",e.InitialSysLogReadError="InitialSysLogReadError",e.InitialSysLogParseError="InitialSysLogParseError",e.InitialCommonLogRead="InitialCommonLogRead",e.InitialCommonLogReadError="InitialCommonLogReadError",e.InitialCommonLogParseError="InitialCommonLogParseError",e.CommonLoggerInitError="CommonLoggerInitError",e.Normal="Normal",e.OpenFileError="OpenFileError",e.ChunkQuotaError="ChunkQuotaError",e.DeviceIoError="DeviceIoError",e.Stopped="Stopped",e.Missing="Missing",e.Timeout="Timeout",e.NodeDisconnected="NodeDisconnected",e.Unknown="Unknown",e}({})},96927:(e,t,n)=>{n.d(t,{O:()=>y,f:()=>k});var s=n(59284),o=n(87184),a=n(92459),r=n(24600),i=n(54090),l=n(7435),d=n(76086),u=n(31684),c=n(90182),m=n(12888),p=n(41650),h=n(60073),g=n(25196),v=n(50672),f=n(60712);const S=[i.m.Orange,i.m.Red,i.m.Yellow],k=(e,t,n)=>{const{AvailableSize:s,TotalSize:r,State:i,PDiskId:c,NodeId:m,StringifiedId:h,Path:k,Realtime:y,Type:b,Device:N}=e,D=[{label:"PDisk",value:null!==h&&void 0!==h?h:d.Pd},{label:"State",value:i||"not available"},{label:"Type",value:b||"unknown"}];if(m&&D.push({label:"Node Id",value:m}),null!==t&&void 0!==t&&t.Host&&D.push({label:"Host",value:t.Host}),null!==t&&void 0!==t&&t.DC&&D.push({label:"DC",value:t.DC}),k&&D.push({label:"Path",value:k}),(0,p.kf)(r)&&D.push({label:"Available",value:`${(0,p.wb)(s)} of ${(0,p.wb)(r)}`}),y&&S.includes(y)&&D.push({label:"Realtime",value:y}),N&&S.includes(N)&&D.push({label:"Device",value:N}),n&&(0,l.f8)(m)&&(0,l.f8)(c)){const e=(0,u.ar)({nodeId:m,pDiskId:c}),t=(0,a.Ck)(c,m);D.push({label:"Links",value:(0,f.jsxs)(o.s,{gap:2,wrap:"wrap",children:[(0,f.jsx)(g.K,{title:(0,v.D)("pdisk-page"),url:t,external:!1}),(0,f.jsx)(g.K,{title:(0,v.D)("developer-ui"),url:e})]})})}return D},y=({data:e})=>{const t=(0,m.X)(),n=(0,c.N4)(r.K),o=(0,l.f8)(e.NodeId)?null===n||void 0===n?void 0:n.get(e.NodeId):void 0,a=s.useMemo((()=>k(e,o,t)),[e,o,t]);return(0,f.jsx)(h.z_,{title:"PDisk",info:a,size:"s"})}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/65988.11e4149b.chunk.js b/ydb/core/viewer/monitoring/static/js/65988.11e4149b.chunk.js new file mode 100644 index 000000000000..04b766e299a4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/65988.11e4149b.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 65988.11e4149b.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[65988],{65988:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>o,language:()=>s});var o={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]}]},s={defaultToken:"",tokenPostfix:".aes",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["contract","library","entrypoint","function","stateful","state","hash","signature","tuple","list","address","string","bool","int","record","datatype","type","option","oracle","oracle_query","Call","Bits","Bytes","Oracle","String","Crypto","Address","Auth","Chain","None","Some","bits","bytes","event","let","map","private","public","true","false","var","if","else","throw"],operators:["=",">","<","!","~","?","::",":","==","<=",">=","!=","&&","||","++","--","+","-","*","/","&","|","^","%","<<",">>",">>>","+=","-=","*=","/=","&=","|=","^=","%=","<<=",">>=",">>>="],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?(@floatsuffix)/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?(@floatsuffix)/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F](@integersuffix)/,"number.hex"],[/0[0-7']*[0-7](@integersuffix)/,"number.octal"],[/0[bB][0-1']*[0-1](@integersuffix)/,"number.binary"],[/\d[\d']*\d(@integersuffix)/,"number"],[/\d(@integersuffix)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6554.6dfab136.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/65988.11e4149b.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6554.6dfab136.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/65988.11e4149b.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/6625.a8d44d36.chunk.js b/ydb/core/viewer/monitoring/static/js/6625.a8d44d36.chunk.js deleted file mode 100644 index b406f9e377be..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6625.a8d44d36.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6625],{26625:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-au",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekStart:1,weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"h:mm A",LTS:"h:mm:ss A",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY h:mm A",LLLL:"dddd, D MMMM YYYY h:mm A"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/66262.b361ce28.chunk.js b/ydb/core/viewer/monitoring/static/js/66262.b361ce28.chunk.js new file mode 100644 index 000000000000..20806fa2e86b --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66262.b361ce28.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 66262.b361ce28.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66262],{66262:(e,n,i)=>{i.r(n),i.d(n,{conf:()=>t,language:()=>r});var t={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["begin","end"],["case","endcase"],["casex","endcase"],["casez","endcase"],["checker","endchecker"],["class","endclass"],["clocking","endclocking"],["config","endconfig"],["function","endfunction"],["generate","endgenerate"],["group","endgroup"],["interface","endinterface"],["module","endmodule"],["package","endpackage"],["primitive","endprimitive"],["program","endprogram"],["property","endproperty"],["specify","endspecify"],["sequence","endsequence"],["table","endtable"],["task","endtask"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],folding:{offSide:!1,markers:{start:new RegExp("^(?:\\s*|.*(?!\\/[\\/\\*])[^\\w])(?:begin|case(x|z)?|class|clocking|config|covergroup|function|generate|interface|module|package|primitive|property|program|sequence|specify|table|task)\\b"),end:new RegExp("^(?:\\s*|.*(?!\\/[\\/\\*])[^\\w])(?:end|endcase|endclass|endclocking|endconfig|endgroup|endfunction|endgenerate|endinterface|endmodule|endpackage|endprimitive|endproperty|endprogram|endsequence|endspecify|endtable|endtask)\\b")}}},r={defaultToken:"",tokenPostfix:".sv",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["accept_on","alias","always","always_comb","always_ff","always_latch","and","assert","assign","assume","automatic","before","begin","bind","bins","binsof","bit","break","buf","bufif0","bufif1","byte","case","casex","casez","cell","chandle","checker","class","clocking","cmos","config","const","constraint","context","continue","cover","covergroup","coverpoint","cross","deassign","default","defparam","design","disable","dist","do","edge","else","end","endcase","endchecker","endclass","endclocking","endconfig","endfunction","endgenerate","endgroup","endinterface","endmodule","endpackage","endprimitive","endprogram","endproperty","endspecify","endsequence","endtable","endtask","enum","event","eventually","expect","export","extends","extern","final","first_match","for","force","foreach","forever","fork","forkjoin","function","generate","genvar","global","highz0","highz1","if","iff","ifnone","ignore_bins","illegal_bins","implements","implies","import","incdir","include","initial","inout","input","inside","instance","int","integer","interconnect","interface","intersect","join","join_any","join_none","large","let","liblist","library","local","localparam","logic","longint","macromodule","matches","medium","modport","module","nand","negedge","nettype","new","nexttime","nmos","nor","noshowcancelled","not","notif0","notif1","null","or","output","package","packed","parameter","pmos","posedge","primitive","priority","program","property","protected","pull0","pull1","pulldown","pullup","pulsestyle_ondetect","pulsestyle_onevent","pure","rand","randc","randcase","randsequence","rcmos","real","realtime","ref","reg","reject_on","release","repeat","restrict","return","rnmos","rpmos","rtran","rtranif0","rtranif1","s_always","s_eventually","s_nexttime","s_until","s_until_with","scalared","sequence","shortint","shortreal","showcancelled","signed","small","soft","solve","specify","specparam","static","string","strong","strong0","strong1","struct","super","supply0","supply1","sync_accept_on","sync_reject_on","table","tagged","task","this","throughout","time","timeprecision","timeunit","tran","tranif0","tranif1","tri","tri0","tri1","triand","trior","trireg","type","typedef","union","unique","unique0","unsigned","until","until_with","untyped","use","uwire","var","vectored","virtual","void","wait","wait_order","wand","weak","weak0","weak1","while","wildcard","wire","with","within","wor","xnor","xor"],builtin_gates:["and","nand","nor","or","xor","xnor","buf","not","bufif0","bufif1","notif1","notif0","cmos","nmos","pmos","rcmos","rnmos","rpmos","tran","tranif1","tranif0","rtran","rtranif1","rtranif0"],operators:["=","+=","-=","*=","/=","%=","&=","|=","^=","<<=",">>+","<<<=",">>>=","?",":","+","-","!","~","&","~&","|","~|","^","~^","^~","+","-","*","/","%","==","!=","===","!==","==?","!=?","&&","||","**","<","<=",">",">=","&","|","^",">>","<<",">>>","<<<","++","--","->","<->","inside","dist","::","+:","-:","*>","&&&","|->","|=>","#=#"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],{include:"@numbers"},[/[;,.]/,"delimiter"],{include:"@strings"}],identifier_or_keyword:[[/@identifier/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}]],numbers:[[/\d+?[\d_]*(?:\.[\d_]+)?[eE][\-+]?\d+/,"number.float"],[/\d+?[\d_]*\.[\d_]+(?:\s*@timeunits)?/,"number.float"],[/(?:\d+?[\d_]*\s*)?'[sS]?[dD]\s*[0-9xXzZ?]+?[0-9xXzZ?_]*/,"number"],[/(?:\d+?[\d_]*\s*)?'[sS]?[bB]\s*[0-1xXzZ?]+?[0-1xXzZ?_]*/,"number.binary"],[/(?:\d+?[\d_]*\s*)?'[sS]?[oO]\s*[0-7xXzZ?]+?[0-7xXzZ?_]*/,"number.octal"],[/(?:\d+?[\d_]*\s*)?'[sS]?[hH]\s*[0-9a-fA-FxXzZ?]+?[0-9a-fA-FxXzZ?_]*/,"number.hex"],[/1step/,"number"],[/[\dxXzZ]+?[\dxXzZ_]*(?:\s*@timeunits)?/,"number"],[/'[01xXzZ]+/,"number"]],module_instance:[{include:"@whitespace"},[/(#?)(\()/,["",{token:"@brackets",next:"@port_connection"}]],[/@identifier\s*[;={}\[\],]/,{token:"@rematch",next:"@pop"}],[/@symbols|[;={}\[\],]/,{token:"@rematch",next:"@pop"}],[/@identifier/,"type"],[/;/,"delimiter","@pop"]],port_connection:[{include:"@identifier_or_keyword"},{include:"@whitespace"},[/@systemcall/,"variable.predefined"],{include:"@numbers"},{include:"@strings"},[/[,]/,"delimiter"],[/\(/,"@brackets","@port_connection"],[/\)/,"@brackets","@pop"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],strings:[[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],include:[[/(\s*)(")([\w*\/*]*)(.\w*)(")/,["","string.include.identifier","string.include.identifier","string.include.identifier",{token:"string.include.identifier",next:"@pop"}]],[/(\s*)(<)([\w*\/*]*)(.\w*)(>)/,["","string.include.identifier","string.include.identifier","string.include.identifier",{token:"string.include.identifier",next:"@pop"}]]],table:[{include:"@whitespace"},[/[()]/,"@brackets"],[/[:;]/,"delimiter"],[/[01\-*?xXbBrRfFpPnN]/,"variable.predefined"],["endtable","keyword.endtable","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6658.b22172da.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/66262.b361ce28.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/6658.b22172da.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/66262.b361ce28.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/66397.32c2f9da.chunk.js b/ydb/core/viewer/monitoring/static/js/66397.32c2f9da.chunk.js new file mode 100644 index 000000000000..2f2bed395e3f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66397.32c2f9da.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66397],{66397:(t,e,a)=>{a.r(e),a.d(e,{completionLists:()=>m,conf:()=>I,language:()=>g});const r=["AND","ANY","AS","ASC","ATTACH","BETWEEN","CASE","CAST","CREATE","CROSS","DATABASE","DATABASES","DEFAULT","DELETE","DESC","DESCRIBE","DETACH","DISTINCT","DROP","ELSE","END","FOREIGN","FROM","GRANT","HAVING","IF","INNER","INSERT","JOIN","KEY","LEFT","NATURAL","NOT","OFFSET","ON","OPTIMIZE","OR","OUTER","PREWHERE","PRIMARY","PROCESSLIST","REFERENCES","RIGHT","SELECT","SHOW","TABLE","THEN","TO","TOTALS","TYPE","UNION","UPDATE","USE","WHEN","WHERE","WITH"],n=["true","false","NULL"],i=["__bitBoolMaskAnd","__bitBoolMaskOr","__bitSwapLastTwo","__bitWrapperFunc","__getScalar","accurate_Cast","accurate_CastOrNull","accurateCast","accurateCastOrNull","acosh","addDays","addHours","addMinutes","addMonths","addQuarters","addressToLine","addressToSymbol","addSeconds","addWeeks","addYears","aes_decrypt_mysql","aes_encrypt_mysql","aggThrow","alphaTokens","and","any","anyHeavy","anyLast","appendTrailingCharIfAbsent","argMax","argMin","array","arrayAll","arrayAUC","arrayAvg","arrayCompact","arrayConcat","arrayCount","arrayCumSum","arrayCumSumNonNegative","arrayDifference","arrayDistinct","arrayElement","arrayEnumerate","arrayEnumerateDense","arrayEnumerateDenseRanked","arrayEnumerateUniq","arrayEnumerateUniqRanked","arrayExists","arrayFill","arrayFilter","arrayFirst","arrayFirstIndex","arrayFlatten","arrayIntersect","arrayJoin","arrayMap","arrayMax","arrayMin","arrayPopBack","arrayPopFront","arrayProduct","arrayPushBack","arrayPushFront","arrayReduce","arrayReduceInRanges","arrayResize","arrayReverse","arrayReverseFill","arrayReverseSort","arrayReverseSplit","arraySlice","arraySort","arraySplit","arrayStringConcat","arraySum","arrayUniq","arrayWithConstant","arrayZip","asinh","assumeNotNull","atanh","avgWeighted","bar","base64Decode","base64Encode","basename","bitAnd","bitCount","bitHammingDistance","bitmaskToArray","bitmaskToList","bitNot","bitOr","bitPositionsToArray","bitRotateLeft","bitRotateRight","bitShiftLeft","bitShiftRight","bitTest","bitTestAll","bitTestAny","bitXor","blockNumber","blockSerializedSize","blockSize","boundingRatio","buildId","byteSize","caseWithExpr","caseWithExpression","caseWithoutExpr","caseWithoutExpression","categoricalInformationValue","cbrt","cityHash64","concatAssumeInjective","ConvertYson","corrStable","cosh","countDigits","countEqual","countMatches","countMatchesCaseInsensitive","countSubstringsCaseInsensitive","countSubstringsCaseInsensitiveUTF8","covarPop","covarPopStable","covarSamp","covarSampStable","currentDatabase","currentProfiles","currentRoles","currentUser","cutFragment","cutIPv6","cutQueryString","cutQueryStringAndFragment","cutToFirstSignificantSubdomain","cutToFirstSignificantSubdomainCustom","cutToFirstSignificantSubdomainCustomWithWWW","cutToFirstSignificantSubdomainWithWWW","cutURLParameter","cutWWW","dateTime64ToSnowflake","dateTimeToSnowflake","dateTrunc","decodeURLComponent","decodeXMLComponent","decrypt","defaultProfiles","defaultRoles","defaultValueOfArgumentType","defaultValueOfTypeName","deltaSum","deltaSumTimestamp","demangle","dictGet","dictGetChildren","dictGetDate","dictGetDateOrDefault","dictGetDateTime","dictGetDateTimeOrDefault","dictGetDescendants","dictGetFloat32","dictGetFloat32OrDefault","dictGetFloat64","dictGetFloat64OrDefault","dictGetHierarchy","dictGetInt8","dictGetInt8OrDefault","dictGetInt16","dictGetInt16OrDefault","dictGetInt32","dictGetInt32OrDefault","dictGetInt64","dictGetInt64OrDefault","dictGetOrDefault","dictGetOrNull","dictGetString","dictGetStringOrDefault","dictGetUInt8","dictGetUInt8OrDefault","dictGetUInt16","dictGetUInt16OrDefault","dictGetUInt32","dictGetUInt32OrDefault","dictGetUInt64","dictGetUInt64OrDefault","dictGetUUID","dictGetUUIDOrDefault","dictHas","dictIsIn","divide","domain","domainWithoutWWW","dumpColumnStructure","e","empty","emptyArrayDate","emptyArrayDateTime","emptyArrayFloat32","emptyArrayFloat64","emptyArrayInt8","emptyArrayInt16","emptyArrayInt32","emptyArrayInt64","emptyArrayString","emptyArrayToSingle","emptyArrayUInt8","emptyArrayUInt16","emptyArrayUInt32","emptyArrayUInt64","enabledProfiles","enabledRoles","encodeXMLComponent","encrypt","endsWith","entropy","equals","erf","erfc","errorCodeToName","evalMLMethod","exp2","exp10","extract","extractAll","extractAllGroups","extractAllGroupsHorizontal","extractAllGroupsVertical","extractGroups","extractTextFromHTML","extractURLParameter","extractURLParameterNames","extractURLParameters","farmFingerprint64","farmHash64","file","filesystemAvailable","filesystemCapacity","filesystemFree","finalizeAggregation","firstSignificantSubdomain","firstSignificantSubdomainCustom","format","formatDateTime","formatReadableQuantity","formatReadableSize","formatReadableTimeDelta","formatRow","formatRowNoNewline","fragment","FROM_UNIXTIME","fromModifiedJulianDay","fromModifiedJulianDayOrNull","fromUnixTimestamp","fromUnixTimestamp64Micro","fromUnixTimestamp64Milli","fromUnixTimestamp64Nano","fullHostName","fuzzBits","gcd","generateUUIDv4","geoDistance","geohashDecode","geohashEncode","geohashesInBox","geoToH3","getMacro","getServerPort","getSetting","getSizeOfEnumType","globalIn","globalInIgnoreSet","globalNotIn","globalNotInIgnoreSet","globalNotNullIn","globalNotNullInIgnoreSet","globalNullIn","globalNullInIgnoreSet","globalVariable","greatCircleAngle","greatCircleDistance","greater","greaterOrEquals","groupArray","groupArrayInsertAt","groupArrayMovingAvg","groupArrayMovingSum","groupArraySample","groupBitAnd","groupBitOr","groupBitXor","groupUniqArray","h3EdgeAngle","h3EdgeLengthM","h3GetBaseCell","h3GetResolution","h3HexAreaM2","h3IndexesAreNeighbors","h3IsValid","h3kRing","h3ToChildren","h3ToGeo","h3ToParent","h3ToString","halfMD5","has","hasAll","hasAny","hasColumnInTable","hasSubstr","hasThreadFuzzer","hasToken","hasTokenCaseInsensitive","histogram","hiveHash","hostName","hostname","identity","ifNotFinite","ignore","ilike","in","indexHint","indexOf","inIgnoreSet","initializeAggregation","initialQueryID","intDiv","intDivOrZero","intervalLengthSum","intExp2","intExp10","intHash32","intHash64","IPv4CIDRToRange","IPv4NumToString","IPv4NumToStringClassC","IPv4StringToNum","IPv4ToIPv6","IPv6CIDRToRange","IPv6NumToString","IPv6StringToNum","isConstant","isDecimalOverflow","isFinite","isInfinite","isIPAddressInRange","isIPv4String","isIPv6String","isNaN","isNotNull","isValidJSON","isValidUTF8","isZeroOrNull","javaHash","javaHashUTF16LE","joinGet","joinGetOrNull","JSON_EXISTS","JSON_QUERY","JSON_VALUE","JSONExtract","JSONExtractArrayRaw","JSONExtractBool","JSONExtractFloat","JSONExtractInt","JSONExtractKeysAndValues","JSONExtractKeysAndValuesRaw","JSONExtractRaw","JSONExtractString","JSONExtractUInt","JSONHas","JSONKey","JSONLength","JSONType","jumpConsistentHash","kurtPop","kurtSamp","lagInFrame","lcm","leadInFrame","leftPad","leftPadUTF8","lengthUTF8","less","lessOrEquals","lgamma","like","log1p","logTrace","lowCardinalityIndices","lowCardinalityKeys","lowerUTF8","MACNumToString","MACStringToNum","MACStringToOUI","mannWhitneyUTest","map","mapAdd","mapContains","mapKeys","mapPopulateSeries","mapSubtract","mapValues","match","materialize","maxIntersections","maxIntersectionsPosition","maxMap","MD5","median","medianBFloat16","medianBFloat16Weighted","medianDeterministic","medianExact","medianExactHigh","medianExactLow","medianExactWeighted","medianTDigest","medianTDigestWeighted","medianTiming","medianTimingWeighted","metroHash64","minMap","minus","modelEvaluate","modulo","moduloLegacy","moduloOrZero","multiFuzzyMatchAllIndices","multiFuzzyMatchAny","multiFuzzyMatchAnyIndex","multiIf","multiMatchAllIndices","multiMatchAny","multiMatchAnyIndex","multiply","multiSearchAllPositions","multiSearchAllPositionsCaseInsensitive","multiSearchAllPositionsCaseInsensitiveUTF8","multiSearchAllPositionsUTF8","multiSearchAny","multiSearchAnyCaseInsensitive","multiSearchAnyCaseInsensitiveUTF8","multiSearchAnyUTF8","multiSearchFirstIndex","multiSearchFirstIndexCaseInsensitive","multiSearchFirstIndexCaseInsensitiveUTF8","multiSearchFirstIndexUTF8","multiSearchFirstPosition","multiSearchFirstPositionCaseInsensitive","multiSearchFirstPositionCaseInsensitiveUTF8","multiSearchFirstPositionUTF8","negate","neighbor","netloc","ngramDistance","ngramDistanceCaseInsensitive","ngramDistanceCaseInsensitiveUTF8","ngramDistanceUTF8","ngramMinHash","ngramMinHashArg","ngramMinHashArgCaseInsensitive","ngramMinHashArgCaseInsensitiveUTF8","ngramMinHashArgUTF8","ngramMinHashCaseInsensitive","ngramMinHashCaseInsensitiveUTF8","ngramMinHashUTF8","ngramSearch","ngramSearchCaseInsensitive","ngramSearchCaseInsensitiveUTF8","ngramSearchUTF8","ngramSimHash","ngramSimHashCaseInsensitive","ngramSimHashCaseInsensitiveUTF8","ngramSimHashUTF8","normalizedQueryHash","normalizedQueryHashKeepNames","normalizeQuery","normalizeQueryKeepNames","notEmpty","notEquals","notILike","notIn","notInIgnoreSet","notLike","notNullIn","notNullInIgnoreSet","nullIn","nullInIgnoreSet","or","parseDateTime32BestEffort","parseDateTime32BestEffortOrNull","parseDateTime32BestEffortOrZero","parseDateTime64BestEffort","parseDateTime64BestEffortOrNull","parseDateTime64BestEffortOrZero","parseDateTimeBestEffort","parseDateTimeBestEffortOrNull","parseDateTimeBestEffortOrZero","parseDateTimeBestEffortUS","parseDateTimeBestEffortUSOrNull","parseDateTimeBestEffortUSOrZero","partitionId","path","pathFull","plus","pointInEllipses","pointInPolygon","polygonAreaCartesian","polygonAreaSpherical","polygonConvexHullCartesian","polygonPerimeterCartesian","polygonPerimeterSpherical","polygonsDistanceCartesian","polygonsDistanceSpherical","polygonsEqualsCartesian","polygonsIntersectionCartesian","polygonsIntersectionSpherical","polygonsSymDifferenceCartesian","polygonsSymDifferenceSpherical","polygonsUnionCartesian","polygonsUnionSpherical","polygonsWithinCartesian","polygonsWithinSpherical","port","positionCaseInsensitive","positionCaseInsensitiveUTF8","positionUTF8","protocol","quantile","quantileBFloat16","quantileBFloat16Weighted","quantileDeterministic","quantileExact","quantileExactExclusive","quantileExactHigh","quantileExactInclusive","quantileExactLow","quantileExactWeighted","quantiles","quantilesBFloat16","quantilesBFloat16Weighted","quantilesDeterministic","quantilesExact","quantilesExactExclusive","quantilesExactHigh","quantilesExactInclusive","quantilesExactLow","quantilesExactWeighted","quantilesTDigest","quantilesTDigestWeighted","quantilesTiming","quantilesTimingWeighted","quantileTDigest","quantileTDigestWeighted","quantileTiming","quantileTimingWeighted","queryID","queryString","queryStringAndFragment","rand32","rand64","randConstant","randomFixedString","randomPrintableASCII","randomString","randomStringUTF8","range","rankCorr","readWktMultiPolygon","readWktPoint","readWktPolygon","readWktRing","regexpQuoteMeta","regionHierarchy","regionIn","regionToArea","regionToCity","regionToContinent","regionToCountry","regionToDistrict","regionToName","regionToPopulation","regionToTopContinent","reinterpret","reinterpretAsDate","reinterpretAsDateTime","reinterpretAsFixedString","reinterpretAsFloat32","reinterpretAsFloat64","reinterpretAsInt8","reinterpretAsInt16","reinterpretAsInt32","reinterpretAsInt64","reinterpretAsInt128","reinterpretAsInt256","reinterpretAsString","reinterpretAsUInt8","reinterpretAsUInt16","reinterpretAsUInt32","reinterpretAsUInt64","reinterpretAsUInt128","reinterpretAsUInt256","reinterpretAsUUID","replaceAll","replaceOne","replaceRegexpAll","replaceRegexpOne","replicate","retention","reverseUTF8","rightPad","rightPadUTF8","roundAge","roundBankers","roundDown","roundDuration","roundToExp2","rowNumberInAllBlocks","rowNumberInBlock","runningAccumulate","runningConcurrency","runningDifference","runningDifferenceStartingWithFirstValue","sequenceCount","sequenceMatch","sequenceNextNode","serverUUID","SHA1","SHA224","SHA256","SHA512","shardCount","shardNum","sigmoid","simpleJSONExtractBool","simpleJSONExtractFloat","simpleJSONExtractInt","simpleJSONExtractRaw","simpleJSONExtractString","simpleJSONExtractUInt","simpleJSONHas","simpleLinearRegression","singleValueOrNull","sinh","sipHash64","sipHash128","skewPop","skewSamp","sleep","sleepEachRow","snowflakeToDateTime","snowflakeToDateTime64","splitByChar","splitByNonAlpha","splitByRegexp","splitByString","splitByWhitespace","startsWith","stddevPop","stddevPopStable","stddevSamp","stddevSampStable","stochasticLinearRegression","stochasticLogisticRegression","stringToH3","studentTTest","substringUTF8","subtractDays","subtractHours","subtractMinutes","subtractMonths","subtractQuarters","subtractSeconds","subtractWeeks","subtractYears","sumCount","sumKahan","sumMap","sumMapFiltered","sumMapFilteredWithOverflow","sumMapWithOverflow","sumWithOverflow","svg","tcpPort","tgamma","throwIf","tid","timeSlot","timeSlots","timeZone","timezone","timeZoneOf","timezoneOf","timeZoneOffset","timezoneOffset","toColumnTypeName","toDate","toDate32","toDate32OrNull","toDate32OrZero","toDateOrNull","toDateOrZero","toDateTime","toDateTime32","toDateTime64","toDateTime64OrNull","toDateTime64OrZero","toDateTimeOrNull","toDateTimeOrZero","today","toDayOfMonth","toDayOfWeek","toDayOfYear","toDecimal32","toDecimal32OrNull","toDecimal32OrZero","toDecimal64","toDecimal64OrNull","toDecimal64OrZero","toDecimal128","toDecimal128OrNull","toDecimal128OrZero","toDecimal256","toDecimal256OrNull","toDecimal256OrZero","toFixedString","toFloat32","toFloat32OrNull","toFloat32OrZero","toFloat64","toFloat64OrNull","toFloat64OrZero","toHour","toInt8","toInt8OrNull","toInt8OrZero","toInt16","toInt16OrNull","toInt16OrZero","toInt32","toInt32OrNull","toInt32OrZero","toInt64","toInt64OrNull","toInt64OrZero","toInt128","toInt128OrNull","toInt128OrZero","toInt256","toInt256OrNull","toInt256OrZero","toIntervalDay","toIntervalHour","toIntervalMinute","toIntervalMonth","toIntervalQuarter","toIntervalSecond","toIntervalWeek","toIntervalYear","toIPv4","toIPv6","toISOWeek","toISOYear","toJSONString","toLowCardinality","toMinute","toModifiedJulianDay","toModifiedJulianDayOrNull","toMonday","toMonth","toNullable","topK","topKWeighted","topLevelDomain","toQuarter","toRelativeDayNum","toRelativeHourNum","toRelativeMinuteNum","toRelativeMonthNum","toRelativeQuarterNum","toRelativeSecondNum","toRelativeWeekNum","toRelativeYearNum","toSecond","toStartOfDay","toStartOfFifteenMinutes","toStartOfFiveMinute","toStartOfHour","toStartOfInterval","toStartOfISOYear","toStartOfMinute","toStartOfMonth","toStartOfQuarter","toStartOfSecond","toStartOfTenMinutes","toStartOfWeek","toStartOfYear","toString","toStringCutToZero","toTime","toTimeZone","toTimezone","toTypeName","toUInt8","toUInt8OrNull","toUInt8OrZero","toUInt16","toUInt16OrNull","toUInt16OrZero","toUInt32","toUInt32OrNull","toUInt32OrZero","toUInt64","toUInt64OrNull","toUInt64OrZero","toUInt128","toUInt128OrNull","toUInt128OrZero","toUInt256","toUInt256OrNull","toUInt256OrZero","toUnixTimestamp","toUnixTimestamp64Micro","toUnixTimestamp64Milli","toUnixTimestamp64Nano","toUUID","toUUIDOrNull","toUUIDOrZero","toValidUTF8","toWeek","toYear","toYearWeek","toYYYYMM","toYYYYMMDD","toYYYYMMDDhhmmss","transform","trimBoth","trimLeft","trimRight","tryBase64Decode","tuple","tupleElement","tupleHammingDistance","tupleToNameValuePairs","uniq","uniqCombined","uniqCombined64","uniqExact","uniqHLL12","uniqUpTo","upperUTF8","uptime","URLHash","URLHierarchy","URLPathHierarchy","UUIDNumToString","UUIDStringToNum","validateNestedArraySizes","varPop","varPopStable","varSamp","varSampStable","visibleWidth","visitParamExtractBool","visitParamExtractFloat","visitParamExtractInt","visitParamExtractRaw","visitParamExtractString","visitParamExtractUInt","visitParamHas","welchTTest","windowFunnel","wkt","wordShingleMinHash","wordShingleMinHashArg","wordShingleMinHashArgCaseInsensitive","wordShingleMinHashArgCaseInsensitiveUTF8","wordShingleMinHashArgUTF8","wordShingleMinHashCaseInsensitive","wordShingleMinHashCaseInsensitiveUTF8","wordShingleMinHashUTF8","wordShingleSimHash","wordShingleSimHashCaseInsensitive","wordShingleSimHashCaseInsensitiveUTF8","wordShingleSimHashUTF8","xor","xxHash32","xxHash64","yandexConsistentHash","yesterday","YPathArrayBoolean","YPathArrayBooleanStrict","YPathArrayDouble","YPathArrayDoubleStrict","YPathArrayInt64","YPathArrayInt64Strict","YPathArrayUInt64","YPathArrayUInt64Strict","YPathBoolean","YPathBooleanStrict","YPathDouble","YPathDoubleStrict","YPathExtract","YPathExtractStrict","YPathInt64","YPathInt64Strict","YPathRaw","YPathRawStrict","YPathString","YPathStringStrict","YPathUInt64","YPathUInt64Strict","YSONExtract","YSONExtractArrayRaw","YSONExtractBool","YSONExtractFloat","YSONExtractInt","YSONExtractKeysAndValues","YSONExtractKeysAndValuesRaw","YSONExtractRaw","YSONExtractString","YSONExtractUInt","YSONHas","YSONKey","YSONLength","YSONType"],o=["_CAST","abs","acos","asin","atan","atan2","avg","bin","BIT_AND","BIT_OR","BIT_XOR","CAST","ceil","ceiling","char","CHAR_LENGTH","CHARACTER_LENGTH","coalesce","concat","connection_id","connectionId","corr","cos","count","countSubstrings","COVAR_POP","COVAR_SAMP","CRC32","CRC32IEEE","CRC64","DATABASE","DATE","date_trunc","dateDiff","dateName","DAY","DAYOFMONTH","DAYOFWEEK","DAYOFYEAR","dense_rank","exp","first_value","flatten","floor","FQDN","FROM_BASE64","greatest","hex","HOUR","hypot","if","ifNull","INET6_ATON","INET6_NTOA","INET_ATON","INET_NTOA","initial_query_id","isNull","last_value","lcase","least","length","ln","locate","log","log2","log10","lower","lpad","max","mid","min","MINUTE","mod","MONTH","not","now","now64","nth_value","nullIf","pi","position","pow","power","QUARTER","query_id","rand","rank","repeat","replace","reverse","round","row_number","rpad","SECOND","sign","sin","sqrt","STDDEV_POP","STDDEV_SAMP","substr","substring","sum","tan","tanh","TO_BASE64","trunc","truncate","ucase","unbin","unhex","upper","user","VAR_POP","VAR_SAMP","version","week","YEAR","yearweek"],s=["cluster","clusterAllReplicas","concatYtTables","concatYtTablesLike","concatYtTablesRange","concatYtTablesRegexp","dictionary","executable","file","generateRandom","input","jdbc","merge","null","numbers","numbers_mt","odbc","remote","remoteSecure","url","values","view","ytSubquery","zeros","zeros_mt"],l=["Buffer","Memory","YtTable"],c=["AggregateFunction","Array","Enum8","Enum16","FixedString","Float32","Float64","Int8","Int16","Int32","Int64","Int128","Int256","IntervalDay","IntervalHour","IntervalMinute","IntervalMonth","IntervalQuarter","IntervalSecond","IntervalWeek","IntervalYear","IPv4","IPv6","LowCardinality","Map","MultiPolygon","Nested","Nothing","Nullable","Point","Polygon","Ring","SimpleAggregateFunction","String","Tuple","UInt8","UInt16","UInt32","UInt64","UInt128","UInt256","UUID","YtBoolean"],u=["BIGINT","BIGINT SIGNED","BIGINT UNSIGNED","BINARY","BINARY LARGE OBJECT","BINARY VARYING","BLOB","BOOL","BOOLEAN","BYTE","BYTEA","CHAR","CHAR LARGE OBJECT","CHAR VARYING","CHARACTER","CHARACTER LARGE OBJECT","CHARACTER VARYING","CLOB","DEC","DOUBLE","DOUBLE PRECISION","Date","Date32","DateTime","DateTime32","DateTime64","Decimal","Decimal128","Decimal256","Decimal32","Decimal64","ENUM","Enum","FIXED","FLOAT","INET4","INET6","INT","INT SIGNED","INT UNSIGNED","INT1","INT1 SIGNED","INT1 UNSIGNED","INTEGER","INTEGER SIGNED","INTEGER UNSIGNED","LONGBLOB","LONGTEXT","MEDIUMBLOB","MEDIUMINT","MEDIUMINT SIGNED","MEDIUMINT UNSIGNED","MEDIUMTEXT","NATIONAL CHAR","NATIONAL CHAR VARYING","NATIONAL CHARACTER","NATIONAL CHARACTER LARGE OBJECT","NATIONAL CHARACTER VARYING","NCHAR","NCHAR LARGE OBJECT","NCHAR VARYING","NUMERIC","NVARCHAR","REAL","SINGLE","SMALLINT","SMALLINT SIGNED","SMALLINT UNSIGNED","TEXT","TIMESTAMP","TINYBLOB","TINYINT","TINYINT SIGNED","TINYINT UNSIGNED","TINYTEXT","VARCHAR","VARCHAR2"],m={keywordList:r.concat(["GROUP BY","ON CLUSTER","ORDER BY","LIMIT","RENAME TABLE","IF NOT EXISTS","IF EXISTS","FORMAT Vertical","FORMAT JSONCompact","FORMAT JSONEachRow","FORMAT TSKV","FORMAT TabSeparatedWithNames","FORMAT TabSeparatedWithNamesAndTypes","FORMAT TabSeparatedRaw","FORMAT BlockTabSeparated","FORMAT CSVWithNames","FORMAT CSV","FORMAT JSON","FORMAT TabSeparated"]),constantList:n,typeParameterList:c.concat(u,l),functionList:i.concat(o,s)},I={comments:{lineComment:"--",blockComment:["```","```"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"`",close:"`",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},T=A(r),S=A(u.filter((t=>/^\S*$/.test(t))));const d=A(o),g={defaultToken:"text",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"}],keywords:r,keywordsDouble:[`${p("GROUP")}\\W+${p("BY")}`,`${p("ON")}\\W+${p("CLUSTER")}`,`${p("ORDER")}\\W+${p("BY")}`,`${p("LIMIT")}\\W+\\d+\\W*,\\W*\\d+`,`${p("LIMIT")}\\W+\\d+\\W+${p("BY")}\\W+`,`${p("LIMIT")}\\W+\\d+`,`${p("RENAME")}\\W+${p("TABLE")}`,`${p("IF")}\\W+${p("NOT")}\\W+${p("EXISTS")}`,`${p("IF")}\\W+${p("EXISTS")}`,`${p("FORMAT")}\\W+Vertical`,`${p("FORMAT")}\\W+JSONCompact`,`${p("FORMAT")}\\W+JSONEachRow`,`${p("FORMAT")}\\W+TSKV`,`${p("FORMAT")}\\W+TabSeparatedWithNames`,`${p("FORMAT")}\\W+TabSeparatedWithNamesAndTypes`,`${p("FORMAT")}\\W+TabSeparatedRaw`,`${p("FORMAT")}\\W+BlockTabSeparated`,`${p("FORMAT")}\\W+CSVWithNames`,`${p("FORMAT")}\\W+CSV`,`${p("FORMAT")}\\W+JSON`,`${p("FORMAT")}\\W+TabSeparated`].join("|"),typeKeywords:c,typeKeywordsDouble:A(function(t){return t.filter((t=>/\s/.test(t))).sort(((t,e)=>e.localeCompare(t)))}(u)),constants:n,builtinFunctions:i,tableFunctions:s,tableEngines:l,operators:["+","-","/","//","%","<@>","@>","<@","&","^","~","<",">","<=","=>","==","!=","<>","="],symbols:/[=>\w+)?/,tokenizer:{root:[{include:"@whitespace"},{include:"@comments"},{include:"@numbers"},{include:"@strings"},[/[$@:](@variables)/,"variable"],[/{(@variables)}/,"variable"],[/[?;,.]/,"delimiter"],[/[(){}[\]]/,"@brackets"],[/@keywordsDouble/,"keyword"],[/@typeKeywordsDouble/,"keyword.type"],[/[a-zA-Z_$][\w$]*/,{cases:{[T]:{token:"keyword"},"@constants":{token:"constant"},"@builtinFunctions":{token:"constant.other.color"},[d]:{token:"constant.other.color"},"@tableFunctions":{token:"constant.other.color"},"@tableEngines":{token:"constant.other.color"},"@typeKeywords":{token:"keyword.type"},[S]:{token:"keyword.type"},"@default":"identifier"}}],[/@symbols/,{cases:{"@operators":"operator.sql","@default":""}}]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/```/,{token:"comment.quote",next:"@comment"}],[/\/\*/,{token:"comment.quote",next:"@cppComment"}]],comment:[[/[^`]+/,"comment"],[/```/,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],cppComment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],numbers:[[/[+-]?\d+(?:(?:\.\d*)?(?:[eE][+-]?\d+)?)?\b/,"number"]],strings:[[/'/,{token:"string",next:"@stringSingle"}],[/"/,{token:"string.tablepath",next:"@stringDouble"}],[/`/,{token:"string.tablepath",next:"@stringBacktick"}]],stringSingle:[[/[^\\']/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/'/,{token:"string",next:"@pop"}]],stringDouble:[[/[^\\"]/,"string.tablepath"],[/@escapes/,"string.tablepath"],[/\\./,"string.tablepath"],[/"/,{token:"string.tablepath",next:"@pop"}]],stringBacktick:[[/[^\\`]/,"string.tablepath"],[/@escapes/,"string.tablepath"],[/\\./,"string.tablepath"],[/`/,{token:"string.tablepath",next:"@pop"}]]}};function p(t){return t.split("").map((t=>/[a-zA-Z]/.test(t)?`[${t.toLowerCase()}${t.toUpperCase()}]`:t)).join("")}function A(t){return`(${t.map((t=>p(t).replace(/\s+/g,"\\s"))).join("|")})`}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/66447.716a34f7.chunk.js b/ydb/core/viewer/monitoring/static/js/66447.716a34f7.chunk.js new file mode 100644 index 000000000000..b4af35087914 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66447.716a34f7.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 66447.716a34f7.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66447],{66447:(e,t,n)=>{n.r(t),n.d(t,{CompletionAdapter:()=>Wt,DefinitionAdapter:()=>Zt,DiagnosticsAdapter:()=>Vt,DocumentColorAdapter:()=>ln,DocumentFormattingEditProvider:()=>cn,DocumentHighlightAdapter:()=>Gt,DocumentLinkAdapter:()=>sn,DocumentRangeFormattingEditProvider:()=>un,DocumentSymbolAdapter:()=>rn,FoldingRangeAdapter:()=>gn,HoverAdapter:()=>$t,ReferenceAdapter:()=>tn,RenameAdapter:()=>nn,SelectionRangeAdapter:()=>pn,WorkerManager:()=>Nt,fromPosition:()=>Kt,fromRange:()=>Ht,getWorker:()=>Kn,setupMode:()=>Xn,toRange:()=>Xt,toTextEdit:()=>qt});var r,i,o=n(80781),a=Object.defineProperty,s=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,u=Object.prototype.hasOwnProperty,d=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of c(t))u.call(e,i)||i===n||a(e,i,{get:()=>t[i],enumerable:!(r=s(t,i))||r.enumerable});return e},l={};d(l,r=o,"default"),i&&d(i,r,"default");var g,f,h,p,m,v,b,k,C,_,w,y,x,E,I,A,S,T,L,R,M,F,P,j,D,N,O,U,V,B,W,K,H,X,z,q,$,Q,J,G,Y,Z,ee,te,ne,re,ie,oe,ae,se,ce,ue,de,le,ge,fe,he,pe,me,ve,be,ke,Ce,_e,we,ye,xe,Ee,Ie,Ae,Se,Te,Le,Re,Me,Fe,Pe,je,De,Ne,Oe,Ue,Ve,Be,We,Ke,He,Xe,ze,qe,$e,Qe,Je,Ge,Ye,Ze,et,tt,nt,rt,it,ot,at,st,ct,ut,dt,lt,gt,ft,ht,pt,mt,vt,bt,kt,Ct,_t,wt,yt,xt,Et,It,At,St,Tt,Lt,Rt,Mt,Ft,Pt,jt,Dt,Nt=class{constructor(e){this._defaults=e,this._worker=null,this._client=null,this._idleCheckInterval=window.setInterval((()=>this._checkIfIdle()),3e4),this._lastUsedTime=0,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker()))}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}dispose(){clearInterval(this._idleCheckInterval),this._configChangeListener.dispose(),this._stopWorker()}_checkIfIdle(){if(!this._worker)return;Date.now()-this._lastUsedTime>12e4&&this._stopWorker()}_getClient(){return this._lastUsedTime=Date.now(),this._client||(this._worker=l.editor.createWebWorker({moduleId:"vs/language/json/jsonWorker",label:this._defaults.languageId,createData:{languageSettings:this._defaults.diagnosticsOptions,languageId:this._defaults.languageId,enableSchemaRequest:this._defaults.diagnosticsOptions.enableSchemaRequest}}),this._client=this._worker.getProxy()),this._client}getLanguageServiceWorker(...e){let t;return this._getClient().then((e=>{t=e})).then((t=>{if(this._worker)return this._worker.withSyncedResources(e)})).then((e=>t))}};(g||(g={})).is=function(e){return"string"===typeof e},(f||(f={})).is=function(e){return"string"===typeof e},(p=h||(h={})).MIN_VALUE=-2147483648,p.MAX_VALUE=2147483647,p.is=function(e){return"number"===typeof e&&p.MIN_VALUE<=e&&e<=p.MAX_VALUE},(v=m||(m={})).MIN_VALUE=0,v.MAX_VALUE=2147483647,v.is=function(e){return"number"===typeof e&&v.MIN_VALUE<=e&&e<=v.MAX_VALUE},(k=b||(b={})).create=function(e,t){return e===Number.MAX_VALUE&&(e=m.MAX_VALUE),t===Number.MAX_VALUE&&(t=m.MAX_VALUE),{line:e,character:t}},k.is=function(e){let t=e;return Ot.objectLiteral(t)&&Ot.uinteger(t.line)&&Ot.uinteger(t.character)},(_=C||(C={})).create=function(e,t,n,r){if(Ot.uinteger(e)&&Ot.uinteger(t)&&Ot.uinteger(n)&&Ot.uinteger(r))return{start:b.create(e,t),end:b.create(n,r)};if(b.is(e)&&b.is(t))return{start:e,end:t};throw new Error(`Range#create called with invalid arguments[${e}, ${t}, ${n}, ${r}]`)},_.is=function(e){let t=e;return Ot.objectLiteral(t)&&b.is(t.start)&&b.is(t.end)},(y=w||(w={})).create=function(e,t){return{uri:e,range:t}},y.is=function(e){let t=e;return Ot.objectLiteral(t)&&C.is(t.range)&&(Ot.string(t.uri)||Ot.undefined(t.uri))},(E=x||(x={})).create=function(e,t,n,r){return{targetUri:e,targetRange:t,targetSelectionRange:n,originSelectionRange:r}},E.is=function(e){let t=e;return Ot.objectLiteral(t)&&C.is(t.targetRange)&&Ot.string(t.targetUri)&&C.is(t.targetSelectionRange)&&(C.is(t.originSelectionRange)||Ot.undefined(t.originSelectionRange))},(A=I||(I={})).create=function(e,t,n,r){return{red:e,green:t,blue:n,alpha:r}},A.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.numberRange(t.red,0,1)&&Ot.numberRange(t.green,0,1)&&Ot.numberRange(t.blue,0,1)&&Ot.numberRange(t.alpha,0,1)},(T=S||(S={})).create=function(e,t){return{range:e,color:t}},T.is=function(e){const t=e;return Ot.objectLiteral(t)&&C.is(t.range)&&I.is(t.color)},(R=L||(L={})).create=function(e,t,n){return{label:e,textEdit:t,additionalTextEdits:n}},R.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.label)&&(Ot.undefined(t.textEdit)||q.is(t))&&(Ot.undefined(t.additionalTextEdits)||Ot.typedArray(t.additionalTextEdits,q.is))},(F=M||(M={})).Comment="comment",F.Imports="imports",F.Region="region",(j=P||(P={})).create=function(e,t,n,r,i,o){const a={startLine:e,endLine:t};return Ot.defined(n)&&(a.startCharacter=n),Ot.defined(r)&&(a.endCharacter=r),Ot.defined(i)&&(a.kind=i),Ot.defined(o)&&(a.collapsedText=o),a},j.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.uinteger(t.startLine)&&Ot.uinteger(t.startLine)&&(Ot.undefined(t.startCharacter)||Ot.uinteger(t.startCharacter))&&(Ot.undefined(t.endCharacter)||Ot.uinteger(t.endCharacter))&&(Ot.undefined(t.kind)||Ot.string(t.kind))},(N=D||(D={})).create=function(e,t){return{location:e,message:t}},N.is=function(e){let t=e;return Ot.defined(t)&&w.is(t.location)&&Ot.string(t.message)},(U=O||(O={})).Error=1,U.Warning=2,U.Information=3,U.Hint=4,(B=V||(V={})).Unnecessary=1,B.Deprecated=2,(W||(W={})).is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.href)},(H=K||(K={})).create=function(e,t,n,r,i,o){let a={range:e,message:t};return Ot.defined(n)&&(a.severity=n),Ot.defined(r)&&(a.code=r),Ot.defined(i)&&(a.source=i),Ot.defined(o)&&(a.relatedInformation=o),a},H.is=function(e){var t;let n=e;return Ot.defined(n)&&C.is(n.range)&&Ot.string(n.message)&&(Ot.number(n.severity)||Ot.undefined(n.severity))&&(Ot.integer(n.code)||Ot.string(n.code)||Ot.undefined(n.code))&&(Ot.undefined(n.codeDescription)||Ot.string(null===(t=n.codeDescription)||void 0===t?void 0:t.href))&&(Ot.string(n.source)||Ot.undefined(n.source))&&(Ot.undefined(n.relatedInformation)||Ot.typedArray(n.relatedInformation,D.is))},(z=X||(X={})).create=function(e,t,...n){let r={title:e,command:t};return Ot.defined(n)&&n.length>0&&(r.arguments=n),r},z.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.title)&&Ot.string(t.command)},($=q||(q={})).replace=function(e,t){return{range:e,newText:t}},$.insert=function(e,t){return{range:{start:e,end:e},newText:t}},$.del=function(e){return{range:e,newText:""}},$.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.newText)&&C.is(t.range)},(J=Q||(Q={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},J.is=function(e){const t=e;return Ot.objectLiteral(t)&&Ot.string(t.label)&&(Ot.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(Ot.string(t.description)||void 0===t.description)},(G||(G={})).is=function(e){const t=e;return Ot.string(t)},(Z=Y||(Y={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},Z.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},Z.del=function(e,t){return{range:e,newText:"",annotationId:t}},Z.is=function(e){const t=e;return q.is(t)&&(Q.is(t.annotationId)||G.is(t.annotationId))},(te=ee||(ee={})).create=function(e,t){return{textDocument:e,edits:t}},te.is=function(e){let t=e;return Ot.defined(t)&&fe.is(t.textDocument)&&Array.isArray(t.edits)},(re=ne||(ne={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},re.is=function(e){let t=e;return t&&"create"===t.kind&&Ot.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||Ot.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ot.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||G.is(t.annotationId))},(oe=ie||(ie={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},oe.is=function(e){let t=e;return t&&"rename"===t.kind&&Ot.string(t.oldUri)&&Ot.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||Ot.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ot.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||G.is(t.annotationId))},(se=ae||(ae={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},se.is=function(e){let t=e;return t&&"delete"===t.kind&&Ot.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||Ot.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||Ot.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||G.is(t.annotationId))},(ce||(ce={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>Ot.string(e.kind)?ne.is(e)||ie.is(e)||ae.is(e):ee.is(e))))},(de=ue||(ue={})).create=function(e){return{uri:e}},de.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)},(ge=le||(le={})).create=function(e,t){return{uri:e,version:t}},ge.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)&&Ot.integer(t.version)},(he=fe||(fe={})).create=function(e,t){return{uri:e,version:t}},he.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)&&(null===t.version||Ot.integer(t.version))},(me=pe||(pe={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},me.is=function(e){let t=e;return Ot.defined(t)&&Ot.string(t.uri)&&Ot.string(t.languageId)&&Ot.integer(t.version)&&Ot.string(t.text)},(be=ve||(ve={})).PlainText="plaintext",be.Markdown="markdown",be.is=function(e){const t=e;return t===be.PlainText||t===be.Markdown},(ke||(ke={})).is=function(e){const t=e;return Ot.objectLiteral(e)&&ve.is(t.kind)&&Ot.string(t.value)},(_e=Ce||(Ce={})).Text=1,_e.Method=2,_e.Function=3,_e.Constructor=4,_e.Field=5,_e.Variable=6,_e.Class=7,_e.Interface=8,_e.Module=9,_e.Property=10,_e.Unit=11,_e.Value=12,_e.Enum=13,_e.Keyword=14,_e.Snippet=15,_e.Color=16,_e.File=17,_e.Reference=18,_e.Folder=19,_e.EnumMember=20,_e.Constant=21,_e.Struct=22,_e.Event=23,_e.Operator=24,_e.TypeParameter=25,(ye=we||(we={})).PlainText=1,ye.Snippet=2,(xe||(xe={})).Deprecated=1,(Ie=Ee||(Ee={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},Ie.is=function(e){const t=e;return t&&Ot.string(t.newText)&&C.is(t.insert)&&C.is(t.replace)},(Se=Ae||(Ae={})).asIs=1,Se.adjustIndentation=2,(Te||(Te={})).is=function(e){const t=e;return t&&(Ot.string(t.detail)||void 0===t.detail)&&(Ot.string(t.description)||void 0===t.description)},(Le||(Le={})).create=function(e){return{label:e}},(Re||(Re={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(Fe=Me||(Me={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},Fe.is=function(e){const t=e;return Ot.string(t)||Ot.objectLiteral(t)&&Ot.string(t.language)&&Ot.string(t.value)},(Pe||(Pe={})).is=function(e){let t=e;return!!t&&Ot.objectLiteral(t)&&(ke.is(t.contents)||Me.is(t.contents)||Ot.typedArray(t.contents,Me.is))&&(void 0===e.range||C.is(e.range))},(je||(je={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(De||(De={})).create=function(e,t,...n){let r={label:e};return Ot.defined(t)&&(r.documentation=t),Ot.defined(n)?r.parameters=n:r.parameters=[],r},(Oe=Ne||(Ne={})).Text=1,Oe.Read=2,Oe.Write=3,(Ue||(Ue={})).create=function(e,t){let n={range:e};return Ot.number(t)&&(n.kind=t),n},(Be=Ve||(Ve={})).File=1,Be.Module=2,Be.Namespace=3,Be.Package=4,Be.Class=5,Be.Method=6,Be.Property=7,Be.Field=8,Be.Constructor=9,Be.Enum=10,Be.Interface=11,Be.Function=12,Be.Variable=13,Be.Constant=14,Be.String=15,Be.Number=16,Be.Boolean=17,Be.Array=18,Be.Object=19,Be.Key=20,Be.Null=21,Be.EnumMember=22,Be.Struct=23,Be.Event=24,Be.Operator=25,Be.TypeParameter=26,(We||(We={})).Deprecated=1,(Ke||(Ke={})).create=function(e,t,n,r,i){let o={name:e,kind:t,location:{uri:r,range:n}};return i&&(o.containerName=i),o},(He||(He={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},(ze=Xe||(Xe={})).create=function(e,t,n,r,i,o){let a={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==o&&(a.children=o),a},ze.is=function(e){let t=e;return t&&Ot.string(t.name)&&Ot.number(t.kind)&&C.is(t.range)&&C.is(t.selectionRange)&&(void 0===t.detail||Ot.string(t.detail))&&(void 0===t.deprecated||Ot.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},($e=qe||(qe={})).Empty="",$e.QuickFix="quickfix",$e.Refactor="refactor",$e.RefactorExtract="refactor.extract",$e.RefactorInline="refactor.inline",$e.RefactorRewrite="refactor.rewrite",$e.Source="source",$e.SourceOrganizeImports="source.organizeImports",$e.SourceFixAll="source.fixAll",(Je=Qe||(Qe={})).Invoked=1,Je.Automatic=2,(Ye=Ge||(Ge={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},Ye.is=function(e){let t=e;return Ot.defined(t)&&Ot.typedArray(t.diagnostics,K.is)&&(void 0===t.only||Ot.typedArray(t.only,Ot.string))&&(void 0===t.triggerKind||t.triggerKind===Qe.Invoked||t.triggerKind===Qe.Automatic)},(et=Ze||(Ze={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):X.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},et.is=function(e){let t=e;return t&&Ot.string(t.title)&&(void 0===t.diagnostics||Ot.typedArray(t.diagnostics,K.is))&&(void 0===t.kind||Ot.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||X.is(t.command))&&(void 0===t.isPreferred||Ot.boolean(t.isPreferred))&&(void 0===t.edit||ce.is(t.edit))},(nt=tt||(tt={})).create=function(e,t){let n={range:e};return Ot.defined(t)&&(n.data=t),n},nt.is=function(e){let t=e;return Ot.defined(t)&&C.is(t.range)&&(Ot.undefined(t.command)||X.is(t.command))},(it=rt||(rt={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},it.is=function(e){let t=e;return Ot.defined(t)&&Ot.uinteger(t.tabSize)&&Ot.boolean(t.insertSpaces)},(at=ot||(ot={})).create=function(e,t,n){return{range:e,target:t,data:n}},at.is=function(e){let t=e;return Ot.defined(t)&&C.is(t.range)&&(Ot.undefined(t.target)||Ot.string(t.target))},(ct=st||(st={})).create=function(e,t){return{range:e,parent:t}},ct.is=function(e){let t=e;return Ot.objectLiteral(t)&&C.is(t.range)&&(void 0===t.parent||ct.is(t.parent))},(dt=ut||(ut={})).namespace="namespace",dt.type="type",dt.class="class",dt.enum="enum",dt.interface="interface",dt.struct="struct",dt.typeParameter="typeParameter",dt.parameter="parameter",dt.variable="variable",dt.property="property",dt.enumMember="enumMember",dt.event="event",dt.function="function",dt.method="method",dt.macro="macro",dt.keyword="keyword",dt.modifier="modifier",dt.comment="comment",dt.string="string",dt.number="number",dt.regexp="regexp",dt.operator="operator",dt.decorator="decorator",(gt=lt||(lt={})).declaration="declaration",gt.definition="definition",gt.readonly="readonly",gt.static="static",gt.deprecated="deprecated",gt.abstract="abstract",gt.async="async",gt.modification="modification",gt.documentation="documentation",gt.defaultLibrary="defaultLibrary",(ft||(ft={})).is=function(e){const t=e;return Ot.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(pt=ht||(ht={})).create=function(e,t){return{range:e,text:t}},pt.is=function(e){const t=e;return void 0!==t&&null!==t&&C.is(t.range)&&Ot.string(t.text)},(vt=mt||(mt={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},vt.is=function(e){const t=e;return void 0!==t&&null!==t&&C.is(t.range)&&Ot.boolean(t.caseSensitiveLookup)&&(Ot.string(t.variableName)||void 0===t.variableName)},(kt=bt||(bt={})).create=function(e,t){return{range:e,expression:t}},kt.is=function(e){const t=e;return void 0!==t&&null!==t&&C.is(t.range)&&(Ot.string(t.expression)||void 0===t.expression)},(_t=Ct||(Ct={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},_t.is=function(e){const t=e;return Ot.defined(t)&&C.is(e.stoppedLocation)},(yt=wt||(wt={})).Type=1,yt.Parameter=2,yt.is=function(e){return 1===e||2===e},(Et=xt||(xt={})).create=function(e){return{value:e}},Et.is=function(e){const t=e;return Ot.objectLiteral(t)&&(void 0===t.tooltip||Ot.string(t.tooltip)||ke.is(t.tooltip))&&(void 0===t.location||w.is(t.location))&&(void 0===t.command||X.is(t.command))},(At=It||(It={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},At.is=function(e){const t=e;return Ot.objectLiteral(t)&&b.is(t.position)&&(Ot.string(t.label)||Ot.typedArray(t.label,xt.is))&&(void 0===t.kind||wt.is(t.kind))&&void 0===t.textEdits||Ot.typedArray(t.textEdits,q.is)&&(void 0===t.tooltip||Ot.string(t.tooltip)||ke.is(t.tooltip))&&(void 0===t.paddingLeft||Ot.boolean(t.paddingLeft))&&(void 0===t.paddingRight||Ot.boolean(t.paddingRight))},(St||(St={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Tt||(Tt={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},(Lt||(Lt={})).create=function(e){return{items:e}},(Mt=Rt||(Rt={})).Invoked=0,Mt.Automatic=1,(Ft||(Ft={})).create=function(e,t){return{range:e,text:t}},(Pt||(Pt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(jt||(jt={})).is=function(e){const t=e;return Ot.objectLiteral(t)&&f.is(t.uri)&&Ot.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),o=e.slice(r);t(i,n),t(o,n);let a=0,s=0,c=0;for(;a{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),o=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],a=e.offsetAt(n.range.start),s=e.offsetAt(n.range.end);if(!(s<=o))throw new Error("Overlapping edit");r=r.substring(0,a)+n.newText+r.substring(s,r.length),o=a}return r}}(Dt||(Dt={}));var Ot,Ut=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return b.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return b.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1{let t,n=e.getLanguageId();n===this._languageId&&(this._listener[e.uri.toString()]=e.onDidChangeContent((()=>{window.clearTimeout(t),t=window.setTimeout((()=>this._doValidate(e.uri,n)),500)})),this._doValidate(e.uri,n))},i=e=>{l.editor.setModelMarkers(e,this._languageId,[]);let t=e.uri.toString(),n=this._listener[t];n&&(n.dispose(),delete this._listener[t])};this._disposables.push(l.editor.onDidCreateModel(r)),this._disposables.push(l.editor.onWillDisposeModel(i)),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{i(e.model),r(e.model)}))),this._disposables.push(n((e=>{l.editor.getModels().forEach((e=>{e.getLanguageId()===this._languageId&&(i(e),r(e))}))}))),this._disposables.push({dispose:()=>{l.editor.getModels().forEach(i);for(let e in this._listener)this._listener[e].dispose()}}),l.editor.getModels().forEach(r)}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables.length=0}_doValidate(e,t){this._worker(e).then((t=>t.doValidation(e.toString()))).then((n=>{const r=n.map((e=>function(e,t){let n="number"===typeof t.code?String(t.code):t.code;return{severity:Bt(t.severity),startLineNumber:t.range.start.line+1,startColumn:t.range.start.character+1,endLineNumber:t.range.end.line+1,endColumn:t.range.end.character+1,message:t.message,code:n,source:t.source}}(0,e)));let i=l.editor.getModel(e);i&&i.getLanguageId()===t&&l.editor.setModelMarkers(i,t,r)})).then(void 0,(e=>{console.error(e)}))}};function Bt(e){switch(e){case O.Error:return l.MarkerSeverity.Error;case O.Warning:return l.MarkerSeverity.Warning;case O.Information:return l.MarkerSeverity.Info;case O.Hint:return l.MarkerSeverity.Hint;default:return l.MarkerSeverity.Info}}var Wt=class{constructor(e,t){this._worker=e,this._triggerCharacters=t}get triggerCharacters(){return this._triggerCharacters}provideCompletionItems(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doComplete(i.toString(),Kt(t)))).then((n=>{if(!n)return;const r=e.getWordUntilPosition(t),i=new l.Range(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn),o=n.items.map((e=>{const t={label:e.label,insertText:e.insertText||e.label,sortText:e.sortText,filterText:e.filterText,documentation:e.documentation,detail:e.detail,command:(n=e.command,n&&"editor.action.triggerSuggest"===n.command?{id:n.command,title:n.title,arguments:n.arguments}:void 0),range:i,kind:zt(e.kind)};var n,r;return e.textEdit&&("undefined"!==typeof(r=e.textEdit).insert&&"undefined"!==typeof r.replace?t.range={insert:Xt(e.textEdit.insert),replace:Xt(e.textEdit.replace)}:t.range=Xt(e.textEdit.range),t.insertText=e.textEdit.newText),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(qt)),e.insertTextFormat===we.Snippet&&(t.insertTextRules=l.languages.CompletionItemInsertTextRule.InsertAsSnippet),t}));return{isIncomplete:n.isIncomplete,suggestions:o}}))}};function Kt(e){if(e)return{character:e.column-1,line:e.lineNumber-1}}function Ht(e){if(e)return{start:{line:e.startLineNumber-1,character:e.startColumn-1},end:{line:e.endLineNumber-1,character:e.endColumn-1}}}function Xt(e){if(e)return new l.Range(e.start.line+1,e.start.character+1,e.end.line+1,e.end.character+1)}function zt(e){const t=l.languages.CompletionItemKind;switch(e){case Ce.Text:return t.Text;case Ce.Method:return t.Method;case Ce.Function:return t.Function;case Ce.Constructor:return t.Constructor;case Ce.Field:return t.Field;case Ce.Variable:return t.Variable;case Ce.Class:return t.Class;case Ce.Interface:return t.Interface;case Ce.Module:return t.Module;case Ce.Property:return t.Property;case Ce.Unit:return t.Unit;case Ce.Value:return t.Value;case Ce.Enum:return t.Enum;case Ce.Keyword:return t.Keyword;case Ce.Snippet:return t.Snippet;case Ce.Color:return t.Color;case Ce.File:return t.File;case Ce.Reference:return t.Reference}return t.Property}function qt(e){if(e)return{range:Xt(e.range),text:e.newText}}var $t=class{constructor(e){this._worker=e}provideHover(e,t,n){let r=e.uri;return this._worker(r).then((e=>e.doHover(r.toString(),Kt(t)))).then((e=>{if(e)return{range:Xt(e.range),contents:Jt(e.contents)}}))}};function Qt(e){return"string"===typeof e?{value:e}:(t=e)&&"object"===typeof t&&"string"===typeof t.kind?"plaintext"===e.kind?{value:e.value.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}:{value:e.value}:{value:"```"+e.language+"\n"+e.value+"\n```\n"};var t}function Jt(e){if(e)return Array.isArray(e)?e.map(Qt):[Qt(e)]}var Gt=class{constructor(e){this._worker=e}provideDocumentHighlights(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDocumentHighlights(r.toString(),Kt(t)))).then((e=>{if(e)return e.map((e=>({range:Xt(e.range),kind:Yt(e.kind)})))}))}};function Yt(e){switch(e){case Ne.Read:return l.languages.DocumentHighlightKind.Read;case Ne.Write:return l.languages.DocumentHighlightKind.Write;case Ne.Text:return l.languages.DocumentHighlightKind.Text}return l.languages.DocumentHighlightKind.Text}var Zt=class{constructor(e){this._worker=e}provideDefinition(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDefinition(r.toString(),Kt(t)))).then((e=>{if(e)return[en(e)]}))}};function en(e){return{uri:l.Uri.parse(e.uri),range:Xt(e.range)}}var tn=class{constructor(e){this._worker=e}provideReferences(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.findReferences(i.toString(),Kt(t)))).then((e=>{if(e)return e.map(en)}))}},nn=class{constructor(e){this._worker=e}provideRenameEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doRename(i.toString(),Kt(t),n))).then((e=>function(e){if(!e||!e.changes)return;let t=[];for(let n in e.changes){const r=l.Uri.parse(n);for(let i of e.changes[n])t.push({resource:r,versionId:void 0,textEdit:{range:Xt(i.range),text:i.newText}})}return{edits:t}}(e)))}};var rn=class{constructor(e){this._worker=e}provideDocumentSymbols(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentSymbols(n.toString()))).then((e=>{if(e)return e.map((e=>"children"in e?on(e):{name:e.name,detail:"",containerName:e.containerName,kind:an(e.kind),range:Xt(e.location.range),selectionRange:Xt(e.location.range),tags:[]}))}))}};function on(e){return{name:e.name,detail:e.detail??"",kind:an(e.kind),range:Xt(e.range),selectionRange:Xt(e.selectionRange),tags:e.tags??[],children:(e.children??[]).map((e=>on(e)))}}function an(e){let t=l.languages.SymbolKind;switch(e){case Ve.File:return t.File;case Ve.Module:return t.Module;case Ve.Namespace:return t.Namespace;case Ve.Package:return t.Package;case Ve.Class:return t.Class;case Ve.Method:return t.Method;case Ve.Property:return t.Property;case Ve.Field:return t.Field;case Ve.Constructor:return t.Constructor;case Ve.Enum:return t.Enum;case Ve.Interface:return t.Interface;case Ve.Function:return t.Function;case Ve.Variable:return t.Variable;case Ve.Constant:return t.Constant;case Ve.String:return t.String;case Ve.Number:return t.Number;case Ve.Boolean:return t.Boolean;case Ve.Array:return t.Array}return t.Function}var sn=class{constructor(e){this._worker=e}provideLinks(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentLinks(n.toString()))).then((e=>{if(e)return{links:e.map((e=>({range:Xt(e.range),url:e.target})))}}))}},cn=class{constructor(e){this._worker=e}provideDocumentFormattingEdits(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.format(r.toString(),null,dn(t)).then((e=>{if(e&&0!==e.length)return e.map(qt)}))))}},un=class{constructor(e){this._worker=e,this.canFormatMultipleRanges=!1}provideDocumentRangeFormattingEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.format(i.toString(),Ht(t),dn(n)).then((e=>{if(e&&0!==e.length)return e.map(qt)}))))}};function dn(e){return{tabSize:e.tabSize,insertSpaces:e.insertSpaces}}var ln=class{constructor(e){this._worker=e}provideDocumentColors(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentColors(n.toString()))).then((e=>{if(e)return e.map((e=>({color:e.color,range:Xt(e.range)})))}))}provideColorPresentations(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getColorPresentations(r.toString(),t.color,Ht(t.range)))).then((e=>{if(e)return e.map((e=>{let t={label:e.label};return e.textEdit&&(t.textEdit=qt(e.textEdit)),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(qt)),t}))}))}},gn=class{constructor(e){this._worker=e}provideFoldingRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getFoldingRanges(r.toString(),t))).then((e=>{if(e)return e.map((e=>{const t={start:e.startLine+1,end:e.endLine+1};return"undefined"!==typeof e.kind&&(t.kind=function(e){switch(e){case M.Comment:return l.languages.FoldingRangeKind.Comment;case M.Imports:return l.languages.FoldingRangeKind.Imports;case M.Region:return l.languages.FoldingRangeKind.Region}return}(e.kind)),t}))}))}};var fn,hn,pn=class{constructor(e){this._worker=e}provideSelectionRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getSelectionRanges(r.toString(),t.map(Kt)))).then((e=>{if(e)return e.map((e=>{const t=[];for(;e;)t.push({range:Xt(e.range)}),e=e.parent;return t}))}))}};function mn(e){return 32===e||9===e}function vn(e){return 10===e||13===e}function bn(e){return e>=48&&e<=57}(hn=fn||(fn={}))[hn.lineFeed=10]="lineFeed",hn[hn.carriageReturn=13]="carriageReturn",hn[hn.space=32]="space",hn[hn._0=48]="_0",hn[hn._1=49]="_1",hn[hn._2=50]="_2",hn[hn._3=51]="_3",hn[hn._4=52]="_4",hn[hn._5=53]="_5",hn[hn._6=54]="_6",hn[hn._7=55]="_7",hn[hn._8=56]="_8",hn[hn._9=57]="_9",hn[hn.a=97]="a",hn[hn.b=98]="b",hn[hn.c=99]="c",hn[hn.d=100]="d",hn[hn.e=101]="e",hn[hn.f=102]="f",hn[hn.g=103]="g",hn[hn.h=104]="h",hn[hn.i=105]="i",hn[hn.j=106]="j",hn[hn.k=107]="k",hn[hn.l=108]="l",hn[hn.m=109]="m",hn[hn.n=110]="n",hn[hn.o=111]="o",hn[hn.p=112]="p",hn[hn.q=113]="q",hn[hn.r=114]="r",hn[hn.s=115]="s",hn[hn.t=116]="t",hn[hn.u=117]="u",hn[hn.v=118]="v",hn[hn.w=119]="w",hn[hn.x=120]="x",hn[hn.y=121]="y",hn[hn.z=122]="z",hn[hn.A=65]="A",hn[hn.B=66]="B",hn[hn.C=67]="C",hn[hn.D=68]="D",hn[hn.E=69]="E",hn[hn.F=70]="F",hn[hn.G=71]="G",hn[hn.H=72]="H",hn[hn.I=73]="I",hn[hn.J=74]="J",hn[hn.K=75]="K",hn[hn.L=76]="L",hn[hn.M=77]="M",hn[hn.N=78]="N",hn[hn.O=79]="O",hn[hn.P=80]="P",hn[hn.Q=81]="Q",hn[hn.R=82]="R",hn[hn.S=83]="S",hn[hn.T=84]="T",hn[hn.U=85]="U",hn[hn.V=86]="V",hn[hn.W=87]="W",hn[hn.X=88]="X",hn[hn.Y=89]="Y",hn[hn.Z=90]="Z",hn[hn.asterisk=42]="asterisk",hn[hn.backslash=92]="backslash",hn[hn.closeBrace=125]="closeBrace",hn[hn.closeBracket=93]="closeBracket",hn[hn.colon=58]="colon",hn[hn.comma=44]="comma",hn[hn.dot=46]="dot",hn[hn.doubleQuote=34]="doubleQuote",hn[hn.minus=45]="minus",hn[hn.openBrace=123]="openBrace",hn[hn.openBracket=91]="openBracket",hn[hn.plus=43]="plus",hn[hn.slash=47]="slash",hn[hn.formFeed=12]="formFeed",hn[hn.tab=9]="tab";new Array(20).fill(0).map(((e,t)=>" ".repeat(t)));var kn,Cn=200;new Array(Cn).fill(0).map(((e,t)=>"\n"+" ".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r"+" ".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r\n"+" ".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\n"+"\t".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r"+"\t".repeat(t))),new Array(Cn).fill(0).map(((e,t)=>"\r\n"+"\t".repeat(t)));(kn||(kn={})).DEFAULT={allowTrailingComma:!1};var _n,wn,yn,xn,En,In,An=function(e,t=!1){const n=e.length;let r=0,i="",o=0,a=16,s=0,c=0,u=0,d=0,l=0;function g(t,n){let i=0,o=0;for(;i=48&&t<=57)o=16*o+t-48;else if(t>=65&&t<=70)o=16*o+t-65+10;else{if(!(t>=97&&t<=102))break;o=16*o+t-97+10}r++,i++}return i=n)return o=n,a=17;let t=e.charCodeAt(r);if(mn(t)){do{r++,i+=String.fromCharCode(t),t=e.charCodeAt(r)}while(mn(t));return a=15}if(vn(t))return r++,i+=String.fromCharCode(t),13===t&&10===e.charCodeAt(r)&&(r++,i+="\n"),s++,u=r,a=14;switch(t){case 123:return r++,a=1;case 125:return r++,a=2;case 91:return r++,a=3;case 93:return r++,a=4;case 58:return r++,a=6;case 44:return r++,a=5;case 34:return r++,i=function(){let t="",i=r;for(;;){if(r>=n){t+=e.substring(i,r),l=2;break}const o=e.charCodeAt(r);if(34===o){t+=e.substring(i,r),r++;break}if(92!==o){if(o>=0&&o<=31){if(vn(o)){t+=e.substring(i,r),l=2;break}l=6}r++}else{if(t+=e.substring(i,r),r++,r>=n){l=2;break}switch(e.charCodeAt(r++)){case 34:t+='"';break;case 92:t+="\\";break;case 47:t+="/";break;case 98:t+="\b";break;case 102:t+="\f";break;case 110:t+="\n";break;case 114:t+="\r";break;case 116:t+="\t";break;case 117:const e=g(4,!0);e>=0?t+=String.fromCharCode(e):l=4;break;default:l=5}i=r}}return t}(),a=10;case 47:const c=r-1;if(47===e.charCodeAt(r+1)){for(r+=2;rr,scan:t?function(){let e;do{e=f()}while(e>=12&&e<=15);return e}:f,getToken:()=>a,getTokenValue:()=>i,getTokenOffset:()=>o,getTokenLength:()=>r-o,getTokenStartLine:()=>c,getTokenStartCharacter:()=>o-d,getTokenError:()=>l}};function Sn(e){return{getInitialState:()=>new Wn(null,null,!1,null),tokenize:(t,n)=>function(e,t,n,r=0){let i=0,o=!1;switch(n.scanError){case 2:t='"'+t,i=1;break;case 1:t="/*"+t,i=2}const a=An(t);let s=n.lastWasColon,c=n.parents;const u={tokens:[],endState:n.clone()};for(;;){let d=r+a.getPosition(),l="";const g=a.scan();if(17===g)break;if(d===r+a.getPosition())throw new Error("Scanner did not advance, next 3 characters are: "+t.substr(a.getPosition(),3));switch(o&&(d-=i),o=i>0,g){case 1:c=Bn.push(c,0),l=Ln,s=!1;break;case 2:c=Bn.pop(c),l=Ln,s=!1;break;case 3:c=Bn.push(c,1),l=Rn,s=!1;break;case 4:c=Bn.pop(c),l=Rn,s=!1;break;case 6:l=Mn,s=!0;break;case 5:l=Fn,s=!1;break;case 8:case 9:l=Pn,s=!1;break;case 7:l=jn,s=!1;break;case 10:const e=c?c.type:0;l=s||1===e?Dn:On,s=!1;break;case 11:l=Nn,s=!1}if(e)switch(g){case 12:l=Vn;break;case 13:l=Un}u.endState=new Wn(n.getStateData(),a.getTokenError(),s,c),u.tokens.push({startIndex:d,scopes:l})}return u}(e,t,n)}}(wn=_n||(_n={}))[wn.None=0]="None",wn[wn.UnexpectedEndOfComment=1]="UnexpectedEndOfComment",wn[wn.UnexpectedEndOfString=2]="UnexpectedEndOfString",wn[wn.UnexpectedEndOfNumber=3]="UnexpectedEndOfNumber",wn[wn.InvalidUnicode=4]="InvalidUnicode",wn[wn.InvalidEscapeCharacter=5]="InvalidEscapeCharacter",wn[wn.InvalidCharacter=6]="InvalidCharacter",(xn=yn||(yn={}))[xn.OpenBraceToken=1]="OpenBraceToken",xn[xn.CloseBraceToken=2]="CloseBraceToken",xn[xn.OpenBracketToken=3]="OpenBracketToken",xn[xn.CloseBracketToken=4]="CloseBracketToken",xn[xn.CommaToken=5]="CommaToken",xn[xn.ColonToken=6]="ColonToken",xn[xn.NullKeyword=7]="NullKeyword",xn[xn.TrueKeyword=8]="TrueKeyword",xn[xn.FalseKeyword=9]="FalseKeyword",xn[xn.StringLiteral=10]="StringLiteral",xn[xn.NumericLiteral=11]="NumericLiteral",xn[xn.LineCommentTrivia=12]="LineCommentTrivia",xn[xn.BlockCommentTrivia=13]="BlockCommentTrivia",xn[xn.LineBreakTrivia=14]="LineBreakTrivia",xn[xn.Trivia=15]="Trivia",xn[xn.Unknown=16]="Unknown",xn[xn.EOF=17]="EOF",(In=En||(En={}))[In.InvalidSymbol=1]="InvalidSymbol",In[In.InvalidNumberFormat=2]="InvalidNumberFormat",In[In.PropertyNameExpected=3]="PropertyNameExpected",In[In.ValueExpected=4]="ValueExpected",In[In.ColonExpected=5]="ColonExpected",In[In.CommaExpected=6]="CommaExpected",In[In.CloseBraceExpected=7]="CloseBraceExpected",In[In.CloseBracketExpected=8]="CloseBracketExpected",In[In.EndOfFileExpected=9]="EndOfFileExpected",In[In.InvalidCommentToken=10]="InvalidCommentToken",In[In.UnexpectedEndOfComment=11]="UnexpectedEndOfComment",In[In.UnexpectedEndOfString=12]="UnexpectedEndOfString",In[In.UnexpectedEndOfNumber=13]="UnexpectedEndOfNumber",In[In.InvalidUnicode=14]="InvalidUnicode",In[In.InvalidEscapeCharacter=15]="InvalidEscapeCharacter",In[In.InvalidCharacter=16]="InvalidCharacter";var Tn,Ln="delimiter.bracket.json",Rn="delimiter.array.json",Mn="delimiter.colon.json",Fn="delimiter.comma.json",Pn="keyword.json",jn="keyword.json",Dn="string.value.json",Nn="number.json",On="string.key.json",Un="comment.block.json",Vn="comment.line.json",Bn=class e{constructor(e,t){this.parent=e,this.type=t}static pop(e){return e?e.parent:null}static push(t,n){return new e(t,n)}static equals(e,t){if(!e&&!t)return!0;if(!e||!t)return!1;for(;e&&t;){if(e===t)return!0;if(e.type!==t.type)return!1;e=e.parent,t=t.parent}return!0}},Wn=class e{constructor(e,t,n,r){this._state=e,this.scanError=t,this.lastWasColon=n,this.parents=r}clone(){return new e(this._state,this.scanError,this.lastWasColon,this.parents)}equals(t){return t===this||!!(t&&t instanceof e)&&(this.scanError===t.scanError&&this.lastWasColon===t.lastWasColon&&Bn.equals(this.parents,t.parents))}getStateData(){return this._state}setStateData(e){this._state=e}};function Kn(){return new Promise(((e,t)=>{if(!Tn)return t("JSON not registered!");e(Tn)}))}var Hn=class extends Vt{constructor(e,t,n){super(e,t,n.onDidChange),this._disposables.push(l.editor.onWillDisposeModel((e=>{this._resetSchema(e.uri)}))),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{this._resetSchema(e.model.uri)})))}_resetSchema(e){this._worker().then((t=>{t.resetSchema(e.toString())}))}};function Xn(e){const t=[],n=[],r=new Nt(e);function i(){const{languageId:t,modeConfiguration:r}=e;qn(n),r.documentFormattingEdits&&n.push(l.languages.registerDocumentFormattingEditProvider(t,new cn(Tn))),r.documentRangeFormattingEdits&&n.push(l.languages.registerDocumentRangeFormattingEditProvider(t,new un(Tn))),r.completionItems&&n.push(l.languages.registerCompletionItemProvider(t,new Wt(Tn,[" ",":",'"']))),r.hovers&&n.push(l.languages.registerHoverProvider(t,new $t(Tn))),r.documentSymbols&&n.push(l.languages.registerDocumentSymbolProvider(t,new rn(Tn))),r.tokens&&n.push(l.languages.setTokensProvider(t,Sn(!0))),r.colors&&n.push(l.languages.registerColorProvider(t,new ln(Tn))),r.foldingRanges&&n.push(l.languages.registerFoldingRangeProvider(t,new gn(Tn))),r.diagnostics&&n.push(new Hn(t,Tn,e)),r.selectionRanges&&n.push(l.languages.registerSelectionRangeProvider(t,new pn(Tn)))}t.push(r),Tn=(...e)=>r.getLanguageServiceWorker(...e),i(),t.push(l.languages.setLanguageConfiguration(e.languageId,$n));let o=e.modeConfiguration;return e.onDidChange((e=>{e.modeConfiguration!==o&&(o=e.modeConfiguration,i())})),t.push(zn(n)),zn(t)}function zn(e){return{dispose:()=>qn(e)}}function qn(e){for(;e.length;)e.pop().dispose()}var $n={wordPattern:/(-?\d*\.\d\w*)|([^\[\{\]\}\:\"\,\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string"]},{open:"[",close:"]",notIn:["string"]},{open:'"',close:'"',notIn:["string"]}]}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7118.ce0cd05f.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/66447.716a34f7.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/7118.ce0cd05f.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/66447.716a34f7.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/6658.b22172da.chunk.js b/ydb/core/viewer/monitoring/static/js/6658.b22172da.chunk.js deleted file mode 100644 index d20d8956d34b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6658.b22172da.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6658.b22172da.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6658],{86658:(e,o,r)=>{r.r(o),r.d(o,{conf:()=>t,language:()=>a});var t={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}]},a={defaultToken:"",tokenPostfix:".r",roxygen:["@alias","@aliases","@assignee","@author","@backref","@callGraph","@callGraphDepth","@callGraphPrimitives","@concept","@describeIn","@description","@details","@docType","@encoding","@evalNamespace","@evalRd","@example","@examples","@export","@exportClass","@exportMethod","@exportPattern","@family","@field","@formals","@format","@import","@importClassesFrom","@importFrom","@importMethodsFrom","@include","@inherit","@inheritDotParams","@inheritParams","@inheritSection","@keywords","@md","@method","@name","@noMd","@noRd","@note","@param","@rawNamespace","@rawRd","@rdname","@references","@return","@S3method","@section","@seealso","@setClass","@slot","@source","@template","@templateVar","@title","@TODO","@usage","@useDynLib"],constants:["NULL","FALSE","TRUE","NA","Inf","NaN","NA_integer_","NA_real_","NA_complex_","NA_character_","T","F","LETTERS","letters","month.abb","month.name","pi","R.version.string"],keywords:["break","next","return","if","else","for","in","repeat","while","array","category","character","complex","double","function","integer","list","logical","matrix","numeric","vector","data.frame","factor","library","require","attach","detach","source"],special:["\\n","\\r","\\t","\\b","\\a","\\f","\\v","\\'",'\\"',"\\\\"],brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"}],tokenizer:{root:[{include:"@numbers"},{include:"@strings"},[/[{}\[\]()]/,"@brackets"],{include:"@operators"},[/#'$/,"comment.doc"],[/#'/,"comment.doc","@roxygen"],[/(^#.*$)/,"comment"],[/\s+/,"white"],[/[,:;]/,"delimiter"],[/@[a-zA-Z]\w*/,"tag"],[/[a-zA-Z]\w*/,{cases:{"@keywords":"keyword","@constants":"constant","@default":"identifier"}}]],roxygen:[[/@\w+/,{cases:{"@roxygen":"tag","@eos":{token:"comment.doc",next:"@pop"},"@default":"comment.doc"}}],[/\s+/,{cases:{"@eos":{token:"comment.doc",next:"@pop"},"@default":"comment.doc"}}],[/.*/,{token:"comment.doc",next:"@pop"}]],numbers:[[/0[xX][0-9a-fA-F]+/,"number.hex"],[/-?(\d*\.)?\d+([eE][+\-]?\d+)?/,"number"]],operators:[[/<{1,2}-/,"operator"],[/->{1,2}/,"operator"],[/%[^%\s]+%/,"operator"],[/\*\*/,"operator"],[/%%/,"operator"],[/&&/,"operator"],[/\|\|/,"operator"],[/<>/,"operator"],[/[-+=&|!<>^~*/:$]/,"operator"]],strings:[[/'/,"string.escape","@stringBody"],[/"/,"string.escape","@dblStringBody"]],stringBody:[[/\\./,{cases:{"@special":"string","@default":"error-token"}}],[/'/,"string.escape","@popall"],[/./,"string"]],dblStringBody:[[/\\./,{cases:{"@special":"string","@default":"error-token"}}],[/"/,"string.escape","@popall"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/66593.94c01a99.chunk.js b/ydb/core/viewer/monitoring/static/js/66593.94c01a99.chunk.js new file mode 100644 index 000000000000..817c3bc0a97f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66593.94c01a99.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66593],{66593:(d,e,b)=>{b.d(e,{default:()=>a});var u=b(33592);const a=b.n(u)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6664.b4dbf019.chunk.js b/ydb/core/viewer/monitoring/static/js/6664.b4dbf019.chunk.js deleted file mode 100644 index 3436751bd0bd..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6664.b4dbf019.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6664],{16664:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ml",weekdays:"\u0d1e\u0d3e\u0d2f\u0d31\u0d3e\u0d34\u0d4d\u0d1a_\u0d24\u0d3f\u0d19\u0d4d\u0d15\u0d33\u0d3e\u0d34\u0d4d\u0d1a_\u0d1a\u0d4a\u0d35\u0d4d\u0d35\u0d3e\u0d34\u0d4d\u0d1a_\u0d2c\u0d41\u0d27\u0d28\u0d3e\u0d34\u0d4d\u0d1a_\u0d35\u0d4d\u0d2f\u0d3e\u0d34\u0d3e\u0d34\u0d4d\u0d1a_\u0d35\u0d46\u0d33\u0d4d\u0d33\u0d3f\u0d2f\u0d3e\u0d34\u0d4d\u0d1a_\u0d36\u0d28\u0d3f\u0d2f\u0d3e\u0d34\u0d4d\u0d1a".split("_"),months:"\u0d1c\u0d28\u0d41\u0d35\u0d30\u0d3f_\u0d2b\u0d46\u0d2c\u0d4d\u0d30\u0d41\u0d35\u0d30\u0d3f_\u0d2e\u0d3e\u0d7c\u0d1a\u0d4d\u0d1a\u0d4d_\u0d0f\u0d2a\u0d4d\u0d30\u0d3f\u0d7d_\u0d2e\u0d47\u0d2f\u0d4d_\u0d1c\u0d42\u0d7a_\u0d1c\u0d42\u0d32\u0d48_\u0d13\u0d17\u0d38\u0d4d\u0d31\u0d4d\u0d31\u0d4d_\u0d38\u0d46\u0d2a\u0d4d\u0d31\u0d4d\u0d31\u0d02\u0d2c\u0d7c_\u0d12\u0d15\u0d4d\u0d1f\u0d4b\u0d2c\u0d7c_\u0d28\u0d35\u0d02\u0d2c\u0d7c_\u0d21\u0d3f\u0d38\u0d02\u0d2c\u0d7c".split("_"),weekdaysShort:"\u0d1e\u0d3e\u0d2f\u0d7c_\u0d24\u0d3f\u0d19\u0d4d\u0d15\u0d7e_\u0d1a\u0d4a\u0d35\u0d4d\u0d35_\u0d2c\u0d41\u0d27\u0d7b_\u0d35\u0d4d\u0d2f\u0d3e\u0d34\u0d02_\u0d35\u0d46\u0d33\u0d4d\u0d33\u0d3f_\u0d36\u0d28\u0d3f".split("_"),monthsShort:"\u0d1c\u0d28\u0d41._\u0d2b\u0d46\u0d2c\u0d4d\u0d30\u0d41._\u0d2e\u0d3e\u0d7c._\u0d0f\u0d2a\u0d4d\u0d30\u0d3f._\u0d2e\u0d47\u0d2f\u0d4d_\u0d1c\u0d42\u0d7a_\u0d1c\u0d42\u0d32\u0d48._\u0d13\u0d17._\u0d38\u0d46\u0d2a\u0d4d\u0d31\u0d4d\u0d31._\u0d12\u0d15\u0d4d\u0d1f\u0d4b._\u0d28\u0d35\u0d02._\u0d21\u0d3f\u0d38\u0d02.".split("_"),weekdaysMin:"\u0d1e\u0d3e_\u0d24\u0d3f_\u0d1a\u0d4a_\u0d2c\u0d41_\u0d35\u0d4d\u0d2f\u0d3e_\u0d35\u0d46_\u0d36".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm -\u0d28\u0d41",LTS:"A h:mm:ss -\u0d28\u0d41",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm -\u0d28\u0d41",LLLL:"dddd, D MMMM YYYY, A h:mm -\u0d28\u0d41"},relativeTime:{future:"%s \u0d15\u0d34\u0d3f\u0d1e\u0d4d\u0d1e\u0d4d",past:"%s \u0d2e\u0d41\u0d7b\u0d2a\u0d4d",s:"\u0d05\u0d7d\u0d2a \u0d28\u0d3f\u0d2e\u0d3f\u0d37\u0d19\u0d4d\u0d19\u0d7e",m:"\u0d12\u0d30\u0d41 \u0d2e\u0d3f\u0d28\u0d3f\u0d31\u0d4d\u0d31\u0d4d",mm:"%d \u0d2e\u0d3f\u0d28\u0d3f\u0d31\u0d4d\u0d31\u0d4d",h:"\u0d12\u0d30\u0d41 \u0d2e\u0d23\u0d3f\u0d15\u0d4d\u0d15\u0d42\u0d7c",hh:"%d \u0d2e\u0d23\u0d3f\u0d15\u0d4d\u0d15\u0d42\u0d7c",d:"\u0d12\u0d30\u0d41 \u0d26\u0d3f\u0d35\u0d38\u0d02",dd:"%d \u0d26\u0d3f\u0d35\u0d38\u0d02",M:"\u0d12\u0d30\u0d41 \u0d2e\u0d3e\u0d38\u0d02",MM:"%d \u0d2e\u0d3e\u0d38\u0d02",y:"\u0d12\u0d30\u0d41 \u0d35\u0d7c\u0d37\u0d02",yy:"%d \u0d35\u0d7c\u0d37\u0d02"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/66809.a4c3fdb1.chunk.js b/ydb/core/viewer/monitoring/static/js/66809.a4c3fdb1.chunk.js new file mode 100644 index 000000000000..86bc2b0660de --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66809.a4c3fdb1.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66809],{29016:e=>{function s(e){e.languages["firestore-security-rules"]=e.languages.extend("clike",{comment:/\/\/.*/,keyword:/\b(?:allow|function|if|match|null|return|rules_version|service)\b/,operator:/&&|\|\||[<>!=]=?|[-+*/%]|\b(?:in|is)\b/}),delete e.languages["firestore-security-rules"]["class-name"],e.languages.insertBefore("firestore-security-rules","keyword",{path:{pattern:/(^|[\s(),])(?:\/(?:[\w\xA0-\uFFFF]+|\{[\w\xA0-\uFFFF]+(?:=\*\*)?\}|\$\([\w\xA0-\uFFFF.]+\)))+/,lookbehind:!0,greedy:!0,inside:{variable:{pattern:/\{[\w\xA0-\uFFFF]+(?:=\*\*)?\}|\$\([\w\xA0-\uFFFF.]+\)/,inside:{operator:/=/,keyword:/\*\*/,punctuation:/[.$(){}]/}},punctuation:/\//}},method:{pattern:/(\ballow\s+)[a-z]+(?:\s*,\s*[a-z]+)*(?=\s*[:;])/,lookbehind:!0,alias:"builtin",inside:{punctuation:/,/}}})}e.exports=s,s.displayName="firestoreSecurityRules",s.aliases=[]},66809:(e,s,i)=>{i.d(s,{default:()=>t});var a=i(29016);const t=i.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/66820.ec86ae7a.chunk.js b/ydb/core/viewer/monitoring/static/js/66820.ec86ae7a.chunk.js new file mode 100644 index 000000000000..708801b19846 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66820.ec86ae7a.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 66820.ec86ae7a.chunk.js.LICENSE.txt */ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66820],{494:(e,t,n)=>{"use strict";var a=n(73934),r=n(94667);e.exports=function(e){return a(e)||r(e)}},9009:e=>{"use strict";e.exports=n;var t=n.prototype;function n(e,t,n){this.property=e,this.normal=t,n&&(this.space=n)}t.space=null,t.normal={},t.property={}},11666:(e,t,n)=>{"use strict";var a=n(73125),r=n(71478),o=a.booleanish,l=a.number,c=a.spaceSeparated;e.exports=r({transform:function(e,t){return"role"===t?t:"aria-"+t.slice(4).toLowerCase()},properties:{ariaActiveDescendant:null,ariaAtomic:o,ariaAutoComplete:null,ariaBusy:o,ariaChecked:o,ariaColCount:l,ariaColIndex:l,ariaColSpan:l,ariaControls:c,ariaCurrent:null,ariaDescribedBy:c,ariaDetails:null,ariaDisabled:o,ariaDropEffect:c,ariaErrorMessage:null,ariaExpanded:o,ariaFlowTo:c,ariaGrabbed:o,ariaHasPopup:null,ariaHidden:o,ariaInvalid:null,ariaKeyShortcuts:null,ariaLabel:null,ariaLabelledBy:c,ariaLevel:l,ariaLive:null,ariaModal:o,ariaMultiLine:o,ariaMultiSelectable:o,ariaOrientation:null,ariaOwns:c,ariaPlaceholder:null,ariaPosInSet:l,ariaPressed:o,ariaReadOnly:o,ariaRelevant:null,ariaRequired:o,ariaRoleDescription:c,ariaRowCount:l,ariaRowIndex:l,ariaRowSpan:l,ariaSelected:o,ariaSetSize:l,ariaSort:null,ariaValueMax:l,ariaValueMin:l,ariaValueNow:l,ariaValueText:null,role:null}})},21257:e=>{"use strict";e.exports=JSON.parse('{"0":"\ufffd","128":"\u20ac","130":"\u201a","131":"\u0192","132":"\u201e","133":"\u2026","134":"\u2020","135":"\u2021","136":"\u02c6","137":"\u2030","138":"\u0160","139":"\u2039","140":"\u0152","142":"\u017d","145":"\u2018","146":"\u2019","147":"\u201c","148":"\u201d","149":"\u2022","150":"\u2013","151":"\u2014","152":"\u02dc","153":"\u2122","154":"\u0161","155":"\u203a","156":"\u0153","158":"\u017e","159":"\u0178"}')},22216:e=>{"use strict";function t(e){e.languages.clike={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?(?:\*\/|$)/,lookbehind:!0,greedy:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0,greedy:!0}],string:{pattern:/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0},"class-name":{pattern:/(\b(?:class|extends|implements|instanceof|interface|new|trait)\s+|\bcatch\s+\()[\w.\\]+/i,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:break|catch|continue|do|else|finally|for|function|if|in|instanceof|new|null|return|throw|try|while)\b/,boolean:/\b(?:false|true)\b/,function:/\b\w+(?=\()/,number:/\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?/i,operator:/[<>]=?|[!=]=?=?|--?|\+\+?|&&?|\|\|?|[?*/~^%]/,punctuation:/[{}[\];(),.:]/}}e.exports=t,t.displayName="clike",t.aliases=[]},27376:(e,t,n)=>{"use strict";var a=n(47556),r=n(72996),o=n(91448),l=n(82140).q,c=n(71383).q;e.exports=function(e,t,n){var r=n?function(e){var t,n=e.length,a=-1,r={};for(;++a{e.exports=function(){for(var e={},n=0;n{"use strict";n.d(t,{A:()=>a});const a={'code[class*="language-"]':{textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",wordWrap:"normal",color:"#90a4ae",background:"#fafafa",fontFamily:"Roboto Mono, monospace",fontSize:"1em",lineHeight:"1.5em",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none"},'pre[class*="language-"]':{textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",wordWrap:"normal",color:"#90a4ae",background:"#fafafa",fontFamily:"Roboto Mono, monospace",fontSize:"1em",lineHeight:"1.5em",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none",overflow:"auto",position:"relative",margin:"0.5em 0",padding:"1.25em 1em"},'code[class*="language-"]::-moz-selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"]::-moz-selection':{background:"#cceae7",color:"#263238"},'code[class*="language-"] ::-moz-selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"] ::-moz-selection':{background:"#cceae7",color:"#263238"},'code[class*="language-"]::selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"]::selection':{background:"#cceae7",color:"#263238"},'code[class*="language-"] ::selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"] ::selection':{background:"#cceae7",color:"#263238"},':not(pre) > code[class*="language-"]':{whiteSpace:"normal",borderRadius:"0.2em",padding:"0.1em"},".language-css > code":{color:"#f76d47"},".language-sass > code":{color:"#f76d47"},".language-scss > code":{color:"#f76d47"},'[class*="language-"] .namespace':{Opacity:"0.7"},atrule:{color:"#7c4dff"},"attr-name":{color:"#39adb5"},"attr-value":{color:"#f6a434"},attribute:{color:"#f6a434"},boolean:{color:"#7c4dff"},builtin:{color:"#39adb5"},cdata:{color:"#39adb5"},char:{color:"#39adb5"},class:{color:"#39adb5"},"class-name":{color:"#6182b8"},comment:{color:"#aabfc9"},constant:{color:"#7c4dff"},deleted:{color:"#e53935"},doctype:{color:"#aabfc9"},entity:{color:"#e53935"},function:{color:"#7c4dff"},hexcode:{color:"#f76d47"},id:{color:"#7c4dff",fontWeight:"bold"},important:{color:"#7c4dff",fontWeight:"bold"},inserted:{color:"#39adb5"},keyword:{color:"#7c4dff"},number:{color:"#f76d47"},operator:{color:"#39adb5"},prolog:{color:"#aabfc9"},property:{color:"#39adb5"},"pseudo-class":{color:"#f6a434"},"pseudo-element":{color:"#f6a434"},punctuation:{color:"#39adb5"},regex:{color:"#6182b8"},selector:{color:"#e53935"},string:{color:"#f6a434"},symbol:{color:"#7c4dff"},tag:{color:"#e53935"},unit:{color:"#f76d47"},url:{color:"#e53935"},variable:{color:"#e53935"}}},32990:e=>{"use strict";e.exports=function(e,t){return t in e?e[t]:t}},33592:e=>{"use strict";function t(e){e.languages.markup={comment:{pattern://,greedy:!0},prolog:{pattern:/<\?[\s\S]+?\?>/,greedy:!0},doctype:{pattern:/"'[\]]|"[^"]*"|'[^']*')+(?:\[(?:[^<"'\]]|"[^"]*"|'[^']*'|<(?!!--)|)*\]\s*)?>/i,greedy:!0,inside:{"internal-subset":{pattern:/(^[^\[]*\[)[\s\S]+(?=\]>$)/,lookbehind:!0,greedy:!0,inside:null},string:{pattern:/"[^"]*"|'[^']*'/,greedy:!0},punctuation:/^$|[[\]]/,"doctype-tag":/^DOCTYPE/i,name:/[^\s<>'"]+/}},cdata:{pattern://i,greedy:!0},tag:{pattern:/<\/?(?!\d)[^\s>\/=$<%]+(?:\s(?:\s*[^\s>\/=]+(?:\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))|(?=[\s/>])))+)?\s*\/?>/,greedy:!0,inside:{tag:{pattern:/^<\/?[^\s>\/]+/,inside:{punctuation:/^<\/?/,namespace:/^[^\s>\/:]+:/}},"special-attr":[],"attr-value":{pattern:/=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+)/,inside:{punctuation:[{pattern:/^=/,alias:"attr-equals"},/"|'/]}},punctuation:/\/?>/,"attr-name":{pattern:/[^\s>\/]+/,inside:{namespace:/^[^\s>\/:]+:/}}}},entity:[{pattern:/&[\da-z]{1,8};/i,alias:"named-entity"},/&#x?[\da-f]{1,8};/i]},e.languages.markup.tag.inside["attr-value"].inside.entity=e.languages.markup.entity,e.languages.markup.doctype.inside["internal-subset"].inside=e.languages.markup,e.hooks.add("wrap",(function(e){"entity"===e.type&&(e.attributes.title=e.content.value.replace(/&/,"&"))})),Object.defineProperty(e.languages.markup.tag,"addInlined",{value:function(t,n){var a={};a["language-"+n]={pattern:/(^$)/i,lookbehind:!0,inside:e.languages[n]},a.cdata=/^$/i;var r={"included-cdata":{pattern://i,inside:a}};r["language-"+n]={pattern:/[\s\S]+/,inside:e.languages[n]};var o={};o[t]={pattern:RegExp(/(<__[^>]*>)(?:))*\]\]>|(?!)/.source.replace(/__/g,(function(){return t})),"i"),lookbehind:!0,greedy:!0,inside:r},e.languages.insertBefore("markup","cdata",o)}}),Object.defineProperty(e.languages.markup.tag,"addAttribute",{value:function(t,n){e.languages.markup.tag.inside["special-attr"].push({pattern:RegExp(/(^|["'\s])/.source+"(?:"+t+")"+/\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))/.source,"i"),lookbehind:!0,inside:{"attr-name":/^[^\s=]+/,"attr-value":{pattern:/=[\s\S]+/,inside:{value:{pattern:/(^=\s*(["']|(?!["'])))\S[\s\S]*(?=\2$)/,lookbehind:!0,alias:[n,"language-"+n],inside:e.languages[n]},punctuation:[{pattern:/^=/,alias:"attr-equals"},/"|'/]}}}})}}),e.languages.html=e.languages.markup,e.languages.mathml=e.languages.markup,e.languages.svg=e.languages.markup,e.languages.xml=e.languages.extend("markup",{}),e.languages.ssml=e.languages.xml,e.languages.atom=e.languages.xml,e.languages.rss=e.languages.xml}e.exports=t,t.displayName="markup",t.aliases=["html","mathml","svg","xml","ssml","atom","rss"]},35228:(e,t,n)=>{"use strict";var a=n(31630),r=n(9009);e.exports=function(e){var t,n,o=e.length,l=[],c=[],i=-1;for(;++i{"use strict";n.d(t,{RE:()=>a,XB:()=>o,to:()=>r});const a="$row|$rows|action|add|all|alter|and|any|as|asc|assume|async|bigserial|serial|smallserial|serial8|serial4|serial2|begin|bernoulli|between|by|case|changefeed|column|columns|commit|compact|create|cross|cube|declare|define|delete|desc|dict|discard|distinct|do|drop|else|empty_action|end|erase|evaluate|exclusion|exists|export|family|flatten|for|from|full|global|group|grouping|having|if|ignore|ilike|import|in|index|inner|insert|into|is|join|key|left|like|limit|list|match|not|null|nulls|offset|on|only|optional|or|order|over|partition|pragma|presort|primary|process|reduce|regexp|repeatable|replace|respect|result|return|right|rlike|rollup|sample|schema|select|semi|set|sets|stream|subquery|sync|table|tablesample|then|truncate|union|intersect|except|update|upsert|use|using|values|view|when|where|window|with|without|xor|callable|resource|tagged|generic|unit|void|emptylist|emptydict|flow|callable|resource|tagged|generic|unit|void|emptylist|emptydict|flow".split("|"),r="bool|date|datetime|decimal|double|float|int16|int32|int64|int8|interval|json|jsondocument|string|timestamp|tzdate|tzdatetime|tztimestamp|uint16|uint32|uint64|uint8|utf8|uuid|yson|text|bytes".split("|"),o="abs|aggregate_by|aggregate_list|aggregate_list_distinct|agg_list|agg_list_distinct|as_table|avg|avg_if|adaptivedistancehistogram|adaptivewardhistogram|adaptiveweighthistogram|addmember|addtimezone|aggregateflatten|aggregatetransforminput|aggregatetransformoutput|aggregationfactory|asatom|asdict|asdictstrict|asenum|aslist|asliststrict|asset|assetstrict|asstruct|astagged|astuple|asvariant|atomcode|bitcast|bit_and|bit_or|bit_xor|bool_and|bool_or|bool_xor|bottom|bottom_by|blockwardhistogram|blockweighthistogram|cast|coalesce|concat|concat_strict|correlation|count|count_if|covariance|covariance_population|covariance_sample|callableargument|callableargumenttype|callableresulttype|callabletype|callabletypecomponents|callabletypehandle|choosemembers|combinemembers|countdistinctestimate|currentauthenticateduser|currentoperationid|currentoperationsharedid|currenttzdate|currenttzdatetime|currenttztimestamp|currentutcdate|currentutcdatetime|currentutctimestamp|dense_rank|datatype|datatypecomponents|datatypehandle|dictaggregate|dictcontains|dictcreate|dicthasitems|dictitems|dictkeytype|dictkeys|dictlength|dictlookup|dictpayloadtype|dictpayloads|dicttype|dicttypecomponents|dicttypehandle|each|each_strict|emptydicttype|emptydicttypehandle|emptylisttype|emptylisttypehandle|endswith|ensure|ensureconvertibleto|ensuretype|enum|evaluateatom|evaluatecode|evaluateexpr|evaluatetype|expandstruct|filter|filter_strict|find|first_value|folder|filecontent|filepath|flattenmembers|forceremovemember|forceremovemembers|forcerenamemembers|forcespreadmembers|formatcode|formattype|frombytes|frompg|funccode|greatest|grouping|gathermembers|generictype|histogram|hll|hoppingwindowpgcast|hyperloglog|if|if_strict|instanceof|json_exists|json_query|json_value|jointablerow|just|lag|last_value|lead|least|len|length|like|likely|like_strict|lambdaargumentscount|lambdacode|lambdaoptionalargumentscount|linearhistogram|listaggregate|listall|listany|listavg|listcode|listcollect|listconcat|listcreate|listdistinct|listenumerate|listextend|listextendstrict|listextract|listfilter|listflatmap|listflatten|listfold|listfold1|listfold1map|listfoldmap|listfromrange|listfromtuple|listhas|listhasitems|listhead|listindexof|listitemtype|listlast|listlength|listmap|listmax|listmin|listnotnull|listreplicate|listreverse|listskip|listskipwhile|listskipwhileinclusive|listsort|listsortasc|listsortdesc|listsum|listtake|listtakewhile|listtakewhileinclusive|listtop|listtopsort|listtopasc|listtopdesc|listtopsortasc|listtopsortdesc|listtotuple|listtype|listtypehandle|listunionall|listuniq|listzip|listzipall|loghistogram|logarithmichistogram|max|max_by|max_of|median|min|min_by|min_of|mode|multi_aggregate_by|nanvl|nvl|nothing|nulltype|nulltypehandle|optionalitemtype|optionaltype|optionaltypehandle|percentile|parsefile|parsetype|parsetypehandle|pgand|pgarray|pgcall|pgconst|pgnot|pgop|pgor|pickle|quotecode|range|range_strict|rank|regexp|regexp_strict|rfind|row_number|random|randomnumber|randomuuid|removemember|removemembers|removetimezone|renamemembers|replacemember|reprcode|resourcetype|resourcetypehandle|resourcetypetag|some|stddev|stddev_population|stddev_sample|substring|sum|sum_if|sessionstart|sessionwindow|setcreate|setdifference|setincludes|setintersection|setisdisjoint|setsymmetricdifference|setunion|spreadmembers|stablepickle|startswith|staticmap|staticzip|streamitemtype|streamtype|streamtypehandle|structmembertype|structmembers|structtypecomponents|structtypehandle|subqueryextend|subqueryextendfor|subquerymerge|subquerymergefor|subqueryunionall|subqueryunionallfor|subqueryunionmerge|subqueryunionmergefor|top|topfreq|top_by|tablename|tablepath|tablerecordindex|tablerow|tablerows|taggedtype|taggedtypecomponents|taggedtypehandle|tobytes|todict|tomultidict|topg|toset|tosorteddict|tosortedmultidict|trymember|tupleelementtype|tupletype|tupletypecomponents|tupletypehandle|typehandle|typekind|typeof|udaf|udf|unittype|unpickle|untag|unwrap|variance|variance_population|variance_sample|variant|varianttype|varianttypehandle|variantunderlyingtype|voidtype|voidtypehandle|way|worldcode|weakfield".split("|")},47556:(e,t,n)=>{"use strict";var a=n(72996),r=n(70302),o=n(58974),l="data";e.exports=function(e,t){var n=a(t),p=t,g=o;if(n in e.normal)return e.property[e.normal[n]];n.length>4&&n.slice(0,4)===l&&c.test(t)&&("-"===t.charAt(4)?p=function(e){var t=e.slice(5).replace(i,d);return l+t.charAt(0).toUpperCase()+t.slice(1)}(t):t=function(e){var t=e.slice(4);if(i.test(t))return e;t=t.replace(s,u),"-"!==t.charAt(0)&&(t="-"+t);return l+t}(t),g=r);return new g(p,t)};var c=/^data[-\w.:]+$/i,i=/-[a-z]/g,s=/[A-Z]/g;function u(e){return"-"+e.toLowerCase()}function d(e){return e.charAt(1).toUpperCase()}},48893:(e,t,n)=>{"use strict";var a=n(70730),r=n(27376)(a,"div");r.displayName="html",e.exports=r},50683:e=>{"use strict";function t(e){e.languages.javascript=e.languages.extend("clike",{"class-name":[e.languages.clike["class-name"],{pattern:/(^|[^$\w\xA0-\uFFFF])(?!\s)[_$A-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\.(?:constructor|prototype))/,lookbehind:!0}],keyword:[{pattern:/((?:^|\})\s*)catch\b/,lookbehind:!0},{pattern:/(^|[^.]|\.\.\.\s*)\b(?:as|assert(?=\s*\{)|async(?=\s*(?:function\b|\(|[$\w\xA0-\uFFFF]|$))|await|break|case|class|const|continue|debugger|default|delete|do|else|enum|export|extends|finally(?=\s*(?:\{|$))|for|from(?=\s*(?:['"]|$))|function|(?:get|set)(?=\s*(?:[#\[$\w\xA0-\uFFFF]|$))|if|implements|import|in|instanceof|interface|let|new|null|of|package|private|protected|public|return|static|super|switch|this|throw|try|typeof|undefined|var|void|while|with|yield)\b/,lookbehind:!0}],function:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*(?:\.\s*(?:apply|bind|call)\s*)?\()/,number:{pattern:RegExp(/(^|[^\w$])/.source+"(?:"+/NaN|Infinity/.source+"|"+/0[bB][01]+(?:_[01]+)*n?/.source+"|"+/0[oO][0-7]+(?:_[0-7]+)*n?/.source+"|"+/0[xX][\dA-Fa-f]+(?:_[\dA-Fa-f]+)*n?/.source+"|"+/\d+(?:_\d+)*n/.source+"|"+/(?:\d+(?:_\d+)*(?:\.(?:\d+(?:_\d+)*)?)?|\.\d+(?:_\d+)*)(?:[Ee][+-]?\d+(?:_\d+)*)?/.source+")"+/(?![\w$])/.source),lookbehind:!0},operator:/--|\+\+|\*\*=?|=>|&&=?|\|\|=?|[!=]==|<<=?|>>>?=?|[-+*/%&|^!=<>]=?|\.{3}|\?\?=?|\?\.?|[~:]/}),e.languages.javascript["class-name"][0].pattern=/(\b(?:class|extends|implements|instanceof|interface|new)\s+)[\w.\\]+/,e.languages.insertBefore("javascript","keyword",{regex:{pattern:/((?:^|[^$\w\xA0-\uFFFF."'\])\s]|\b(?:return|yield))\s*)\/(?:\[(?:[^\]\\\r\n]|\\.)*\]|\\.|[^/\\\[\r\n])+\/[dgimyus]{0,7}(?=(?:\s|\/\*(?:[^*]|\*(?!\/))*\*\/)*(?:$|[\r\n,.;:})\]]|\/\/))/,lookbehind:!0,greedy:!0,inside:{"regex-source":{pattern:/^(\/)[\s\S]+(?=\/[a-z]*$)/,lookbehind:!0,alias:"language-regex",inside:e.languages.regex},"regex-delimiter":/^\/|\/$/,"regex-flags":/^[a-z]+$/}},"function-variable":{pattern:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*[=:]\s*(?:async\s*)?(?:\bfunction\b|(?:\((?:[^()]|\([^()]*\))*\)|(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)\s*=>))/,alias:"function"},parameter:[{pattern:/(function(?:\s+(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)?\s*\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\))/,lookbehind:!0,inside:e.languages.javascript},{pattern:/(^|[^$\w\xA0-\uFFFF])(?!\s)[_$a-z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*=>)/i,lookbehind:!0,inside:e.languages.javascript},{pattern:/(\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\)\s*=>)/,lookbehind:!0,inside:e.languages.javascript},{pattern:/((?:\b|\s|^)(?!(?:as|async|await|break|case|catch|class|const|continue|debugger|default|delete|do|else|enum|export|extends|finally|for|from|function|get|if|implements|import|in|instanceof|interface|let|new|null|of|package|private|protected|public|return|set|static|super|switch|this|throw|try|typeof|undefined|var|void|while|with|yield)(?![$\w\xA0-\uFFFF]))(?:(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*\s*)\(\s*|\]\s*\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\)\s*\{)/,lookbehind:!0,inside:e.languages.javascript}],constant:/\b[A-Z](?:[A-Z_]|\dx?)*\b/}),e.languages.insertBefore("javascript","string",{hashbang:{pattern:/^#!.*/,greedy:!0,alias:"comment"},"template-string":{pattern:/`(?:\\[\s\S]|\$\{(?:[^{}]|\{(?:[^{}]|\{[^}]*\})*\})+\}|(?!\$\{)[^\\`])*`/,greedy:!0,inside:{"template-punctuation":{pattern:/^`|`$/,alias:"string"},interpolation:{pattern:/((?:^|[^\\])(?:\\{2})*)\$\{(?:[^{}]|\{(?:[^{}]|\{[^}]*\})*\})+\}/,lookbehind:!0,inside:{"interpolation-punctuation":{pattern:/^\$\{|\}$/,alias:"punctuation"},rest:e.languages.javascript}},string:/[\s\S]+/}},"string-property":{pattern:/((?:^|[,{])[ \t]*)(["'])(?:\\(?:\r\n|[\s\S])|(?!\2)[^\\\r\n])*\2(?=\s*:)/m,lookbehind:!0,greedy:!0,alias:"property"}}),e.languages.insertBefore("javascript","operator",{"literal-property":{pattern:/((?:^|[,{])[ \t]*)(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*:)/m,lookbehind:!0,alias:"property"}}),e.languages.markup&&(e.languages.markup.tag.addInlined("script","javascript"),e.languages.markup.tag.addAttribute(/on(?:abort|blur|change|click|composition(?:end|start|update)|dblclick|error|focus(?:in|out)?|key(?:down|up)|load|mouse(?:down|enter|leave|move|out|over|up)|reset|resize|scroll|select|slotchange|submit|unload|wheel)/.source,"javascript")),e.languages.js=e.languages.javascript}e.exports=t,t.displayName="javascript",t.aliases=["js"]},55942:(e,t,n)=>{"use strict";e.exports=n(48893)},58974:e=>{"use strict";e.exports=n;var t=n.prototype;function n(e,t){this.property=e,this.attribute=t}t.space=null,t.attribute=null,t.property=null,t.boolean=!1,t.booleanish=!1,t.overloadedBoolean=!1,t.number=!1,t.commaSeparated=!1,t.spaceSeparated=!1,t.commaOrSpaceSeparated=!1,t.mustUseProperty=!1,t.defined=!1},59162:(e,t,n)=>{"use strict";var a=n(73125),r=n(71478),o=n(70503),l=a.boolean,c=a.overloadedBoolean,i=a.booleanish,s=a.number,u=a.spaceSeparated,d=a.commaSeparated;e.exports=r({space:"html",attributes:{acceptcharset:"accept-charset",classname:"class",htmlfor:"for",httpequiv:"http-equiv"},transform:o,mustUseProperty:["checked","multiple","muted","selected"],properties:{abbr:null,accept:d,acceptCharset:u,accessKey:u,action:null,allow:null,allowFullScreen:l,allowPaymentRequest:l,allowUserMedia:l,alt:null,as:null,async:l,autoCapitalize:null,autoComplete:u,autoFocus:l,autoPlay:l,capture:l,charSet:null,checked:l,cite:null,className:u,cols:s,colSpan:null,content:null,contentEditable:i,controls:l,controlsList:u,coords:s|d,crossOrigin:null,data:null,dateTime:null,decoding:null,default:l,defer:l,dir:null,dirName:null,disabled:l,download:c,draggable:i,encType:null,enterKeyHint:null,form:null,formAction:null,formEncType:null,formMethod:null,formNoValidate:l,formTarget:null,headers:u,height:s,hidden:l,high:s,href:null,hrefLang:null,htmlFor:u,httpEquiv:u,id:null,imageSizes:null,imageSrcSet:d,inputMode:null,integrity:null,is:null,isMap:l,itemId:null,itemProp:u,itemRef:u,itemScope:l,itemType:u,kind:null,label:null,lang:null,language:null,list:null,loading:null,loop:l,low:s,manifest:null,max:null,maxLength:s,media:null,method:null,min:null,minLength:s,multiple:l,muted:l,name:null,nonce:null,noModule:l,noValidate:l,onAbort:null,onAfterPrint:null,onAuxClick:null,onBeforePrint:null,onBeforeUnload:null,onBlur:null,onCancel:null,onCanPlay:null,onCanPlayThrough:null,onChange:null,onClick:null,onClose:null,onContextMenu:null,onCopy:null,onCueChange:null,onCut:null,onDblClick:null,onDrag:null,onDragEnd:null,onDragEnter:null,onDragExit:null,onDragLeave:null,onDragOver:null,onDragStart:null,onDrop:null,onDurationChange:null,onEmptied:null,onEnded:null,onError:null,onFocus:null,onFormData:null,onHashChange:null,onInput:null,onInvalid:null,onKeyDown:null,onKeyPress:null,onKeyUp:null,onLanguageChange:null,onLoad:null,onLoadedData:null,onLoadedMetadata:null,onLoadEnd:null,onLoadStart:null,onMessage:null,onMessageError:null,onMouseDown:null,onMouseEnter:null,onMouseLeave:null,onMouseMove:null,onMouseOut:null,onMouseOver:null,onMouseUp:null,onOffline:null,onOnline:null,onPageHide:null,onPageShow:null,onPaste:null,onPause:null,onPlay:null,onPlaying:null,onPopState:null,onProgress:null,onRateChange:null,onRejectionHandled:null,onReset:null,onResize:null,onScroll:null,onSecurityPolicyViolation:null,onSeeked:null,onSeeking:null,onSelect:null,onSlotChange:null,onStalled:null,onStorage:null,onSubmit:null,onSuspend:null,onTimeUpdate:null,onToggle:null,onUnhandledRejection:null,onUnload:null,onVolumeChange:null,onWaiting:null,onWheel:null,open:l,optimum:s,pattern:null,ping:u,placeholder:null,playsInline:l,poster:null,preload:null,readOnly:l,referrerPolicy:null,rel:u,required:l,reversed:l,rows:s,rowSpan:s,sandbox:u,scope:null,scoped:l,seamless:l,selected:l,shape:null,size:s,sizes:null,slot:null,span:s,spellCheck:i,src:null,srcDoc:null,srcLang:null,srcSet:d,start:s,step:null,style:null,tabIndex:s,target:null,title:null,translate:null,type:null,typeMustMatch:l,useMap:null,value:i,width:s,wrap:null,align:null,aLink:null,archive:u,axis:null,background:null,bgColor:null,border:s,borderColor:null,bottomMargin:s,cellPadding:null,cellSpacing:null,char:null,charOff:null,classId:null,clear:null,code:null,codeBase:null,codeType:null,color:null,compact:l,declare:l,event:null,face:null,frame:null,frameBorder:null,hSpace:s,leftMargin:s,link:null,longDesc:null,lowSrc:null,marginHeight:s,marginWidth:s,noResize:l,noHref:l,noShade:l,noWrap:l,object:null,profile:null,prompt:null,rev:null,rightMargin:s,rules:null,scheme:null,scrolling:i,standby:null,summary:null,text:null,topMargin:s,valueType:null,version:null,vAlign:null,vLink:null,vSpace:s,allowTransparency:null,autoCorrect:null,autoSave:null,disablePictureInPicture:l,disableRemotePlayback:l,prefix:null,property:null,results:s,security:null,unselectable:null}})},61945:(e,t,n)=>{"use strict";var a=n(71478),r=n(70503);e.exports=a({space:"xmlns",attributes:{xmlnsxlink:"xmlns:xlink"},transform:r,properties:{xmlns:null,xmlnsXLink:null}})},61993:e=>{"use strict";function t(e){!function(e){var t=/(?:"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"|'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n])*')/;e.languages.css={comment:/\/\*[\s\S]*?\*\//,atrule:{pattern:/@[\w-](?:[^;{\s]|\s+(?![\s{]))*(?:;|(?=\s*\{))/,inside:{rule:/^@[\w-]+/,"selector-function-argument":{pattern:/(\bselector\s*\(\s*(?![\s)]))(?:[^()\s]|\s+(?![\s)])|\((?:[^()]|\([^()]*\))*\))+(?=\s*\))/,lookbehind:!0,alias:"selector"},keyword:{pattern:/(^|[^\w-])(?:and|not|only|or)(?![\w-])/,lookbehind:!0}}},url:{pattern:RegExp("\\burl\\((?:"+t.source+"|"+/(?:[^\\\r\n()"']|\\[\s\S])*/.source+")\\)","i"),greedy:!0,inside:{function:/^url/i,punctuation:/^\(|\)$/,string:{pattern:RegExp("^"+t.source+"$"),alias:"url"}}},selector:{pattern:RegExp("(^|[{}\\s])[^{}\\s](?:[^{};\"'\\s]|\\s+(?![\\s{])|"+t.source+")*(?=\\s*\\{)"),lookbehind:!0},string:{pattern:t,greedy:!0},property:{pattern:/(^|[^-\w\xA0-\uFFFF])(?!\s)[-_a-z\xA0-\uFFFF](?:(?!\s)[-\w\xA0-\uFFFF])*(?=\s*:)/i,lookbehind:!0},important:/!important\b/i,function:{pattern:/(^|[^-a-z0-9])[-a-z0-9]+(?=\()/i,lookbehind:!0},punctuation:/[(){};:,]/},e.languages.css.atrule.inside.rest=e.languages.css;var n=e.languages.markup;n&&(n.tag.addInlined("style","css"),n.tag.addAttribute("style","css"))}(e)}e.exports=t,t.displayName="css",t.aliases=[]},62422:(e,t,n)=>{"use strict";n.d(t,{A:()=>a});const a={'pre[class*="language-"]':{color:"#d4d4d4",fontSize:"13px",textShadow:"none",fontFamily:'Menlo, Monaco, Consolas, "Andale Mono", "Ubuntu Mono", "Courier New", monospace',direction:"ltr",textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",lineHeight:"1.5",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none",padding:"1em",margin:".5em 0",overflow:"auto",background:"#1e1e1e"},'code[class*="language-"]':{color:"#d4d4d4",fontSize:"13px",textShadow:"none",fontFamily:'Menlo, Monaco, Consolas, "Andale Mono", "Ubuntu Mono", "Courier New", monospace',direction:"ltr",textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",lineHeight:"1.5",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none"},'pre[class*="language-"]::selection':{textShadow:"none",background:"#264F78"},'code[class*="language-"]::selection':{textShadow:"none",background:"#264F78"},'pre[class*="language-"] *::selection':{textShadow:"none",background:"#264F78"},'code[class*="language-"] *::selection':{textShadow:"none",background:"#264F78"},':not(pre) > code[class*="language-"]':{padding:".1em .3em",borderRadius:".3em",color:"#db4c69",background:"#1e1e1e"},".namespace":{Opacity:".7"},"doctype.doctype-tag":{color:"#569CD6"},"doctype.name":{color:"#9cdcfe"},comment:{color:"#6a9955"},prolog:{color:"#6a9955"},punctuation:{color:"#d4d4d4"},".language-html .language-css .token.punctuation":{color:"#d4d4d4"},".language-html .language-javascript .token.punctuation":{color:"#d4d4d4"},property:{color:"#9cdcfe"},tag:{color:"#569cd6"},boolean:{color:"#569cd6"},number:{color:"#b5cea8"},constant:{color:"#9cdcfe"},symbol:{color:"#b5cea8"},inserted:{color:"#b5cea8"},unit:{color:"#b5cea8"},selector:{color:"#d7ba7d"},"attr-name":{color:"#9cdcfe"},string:{color:"#ce9178"},char:{color:"#ce9178"},builtin:{color:"#ce9178"},deleted:{color:"#ce9178"},".language-css .token.string.url":{textDecoration:"underline"},operator:{color:"#d4d4d4"},entity:{color:"#569cd6"},"operator.arrow":{color:"#569CD6"},atrule:{color:"#ce9178"},"atrule.rule":{color:"#c586c0"},"atrule.url":{color:"#9cdcfe"},"atrule.url.function":{color:"#dcdcaa"},"atrule.url.punctuation":{color:"#d4d4d4"},keyword:{color:"#569CD6"},"keyword.module":{color:"#c586c0"},"keyword.control-flow":{color:"#c586c0"},function:{color:"#dcdcaa"},"function.maybe-class-name":{color:"#dcdcaa"},regex:{color:"#d16969"},important:{color:"#569cd6"},italic:{fontStyle:"italic"},"class-name":{color:"#4ec9b0"},"maybe-class-name":{color:"#4ec9b0"},console:{color:"#9cdcfe"},parameter:{color:"#9cdcfe"},interpolation:{color:"#9cdcfe"},"punctuation.interpolation-punctuation":{color:"#569cd6"},variable:{color:"#9cdcfe"},"imports.maybe-class-name":{color:"#9cdcfe"},"exports.maybe-class-name":{color:"#9cdcfe"},escape:{color:"#d7ba7d"},"tag.punctuation":{color:"#808080"},cdata:{color:"#808080"},"attr-value":{color:"#ce9178"},"attr-value.punctuation":{color:"#ce9178"},"attr-value.punctuation.attr-equals":{color:"#d4d4d4"},namespace:{color:"#4ec9b0"},'pre[class*="language-javascript"]':{color:"#9cdcfe"},'code[class*="language-javascript"]':{color:"#9cdcfe"},'pre[class*="language-jsx"]':{color:"#9cdcfe"},'code[class*="language-jsx"]':{color:"#9cdcfe"},'pre[class*="language-typescript"]':{color:"#9cdcfe"},'code[class*="language-typescript"]':{color:"#9cdcfe"},'pre[class*="language-tsx"]':{color:"#9cdcfe"},'code[class*="language-tsx"]':{color:"#9cdcfe"},'pre[class*="language-css"]':{color:"#ce9178"},'code[class*="language-css"]':{color:"#ce9178"},'pre[class*="language-html"]':{color:"#d4d4d4"},'code[class*="language-html"]':{color:"#d4d4d4"},".language-regex .token.anchor":{color:"#dcdcaa"},".language-html .token.punctuation":{color:"#808080"},'pre[class*="language-"] > code[class*="language-"]':{position:"relative",zIndex:"1"},".line-highlight.line-highlight":{background:"#f7ebc6",boxShadow:"inset 5px 0 0 #f7d87c",zIndex:"0"}}},64016:e=>{"use strict";var t;e.exports=function(e){var n,a="&"+e+";";if((t=t||document.createElement("i")).innerHTML=a,59===(n=t.textContent).charCodeAt(n.length-1)&&"semi"!==e)return!1;return n!==a&&n}},70302:(e,t,n)=>{"use strict";var a=n(58974),r=n(73125);e.exports=c,c.prototype=new a,c.prototype.defined=!0;var o=["boolean","booleanish","overloadedBoolean","number","commaSeparated","spaceSeparated","commaOrSpaceSeparated"],l=o.length;function c(e,t,n,c){var s,u=-1;for(i(this,"space",c),a.call(this,e,t);++u{"use strict";var a=n(32990);e.exports=function(e,t){return a(e,t.toLowerCase())}},70730:(e,t,n)=>{"use strict";var a=n(35228),r=n(83851),o=n(91622),l=n(61945),c=n(11666),i=n(59162);e.exports=a([o,r,l,c,i])},71383:(e,t)=>{"use strict";t.q=function(e){var t,a=[],o=String(e||r),l=o.indexOf(n),c=0,i=!1;for(;!i;)-1===l&&(l=o.length,i=!0),!(t=o.slice(c,l).trim())&&i||a.push(t),c=l+1,l=o.indexOf(n,c);return a};var n=",",a=" ",r=""},71478:(e,t,n)=>{"use strict";var a=n(72996),r=n(9009),o=n(70302);e.exports=function(e){var t,n,l=e.space,c=e.mustUseProperty||[],i=e.attributes||{},s=e.properties,u=e.transform,d={},p={};for(t in s)n=new o(t,u(i,t),s[t],l),-1!==c.indexOf(t)&&(n.mustUseProperty=!0),d[t]=n,p[a(t)]=t,p[a(n.attribute)]=t;return new r(d,p,l)}},72824:(e,t,n)=>{"use strict";var a=n(82719),r=n(21257),o=n(94667),l=n(83991),c=n(494),i=n(64016);e.exports=function(e,t){var n,o,l={};t||(t={});for(o in p)n=t[o],l[o]=null===n||void 0===n?p[o]:n;(l.position.indent||l.position.start)&&(l.indent=l.position.indent||[],l.position=l.position.start);return function(e,t){var n,o,l,p,R,q,H,B,U,W,V,Z,G,K,J,Y,X,Q,ee,te=t.additional,ne=t.nonTerminated,ae=t.text,re=t.reference,oe=t.warning,le=t.textContext,ce=t.referenceContext,ie=t.warningContext,se=t.position,ue=t.indent||[],de=e.length,pe=0,ge=-1,me=se.column||1,fe=se.line||1,he="",ye=[];"string"===typeof te&&(te=te.charCodeAt(0));Y=be(),B=oe?ve:d,pe--,de++;for(;++pe65535&&(W+=u((q-=65536)>>>10|55296),q=56320|1023&q),q=W+u(q))):K!==F&&B(E,Q)),q?(we(),Y=be(),pe=ee-1,me+=ee-G+1,ye.push(q),(X=be()).offset++,re&&re.call(ce,q,{start:Y,end:X},e.slice(G-1,ee)),Y=X):(p=e.slice(G-1,ee),he+=p,me+=p.length,pe=ee-1)}else 10===R&&(fe++,ge++,me=0),R===R?(he+=u(R),me++):we();return ye.join("");function be(){return{line:fe,column:me,offset:pe+(se.offset||0)}}function ve(e,t){var n=be();n.column+=t,n.offset+=t,oe.call(ie,$[e],n,e)}function we(){he&&(ye.push(he),ae&&ae.call(le,he,{start:Y,end:be()}),he="")}}(e,l)};var s={}.hasOwnProperty,u=String.fromCharCode,d=Function.prototype,p={warning:null,reference:null,text:null,warningContext:null,referenceContext:null,textContext:null,position:{},additional:null,attribute:!1,nonTerminated:!0},g=9,m=10,f=12,h=32,y=38,b=59,v=60,w=61,x=35,k=88,S=120,A=65533,F="named",O="hexadecimal",N="decimal",C={};C[O]=16,C[N]=10;var j={};j[F]=c,j[N]=o,j[O]=l;var P=1,L=2,_=3,E=4,z=5,M=6,T=7,$={};function D(e){return e>=55296&&e<=57343||e>1114111}function I(e){return e>=1&&e<=8||11===e||e>=13&&e<=31||e>=127&&e<=159||e>=64976&&e<=65007||65535===(65535&e)||65534===(65535&e)}$[P]="Named character references must be terminated by a semicolon",$[L]="Numeric character references must be terminated by a semicolon",$[_]="Named character references cannot be empty",$[E]="Numeric character references cannot be empty",$[z]="Named character references must be known",$[M]="Numeric character references cannot be disallowed",$[T]="Numeric character references cannot be outside the permissible Unicode range"},72996:e=>{"use strict";e.exports=function(e){return e.toLowerCase()}},73125:(e,t)=>{"use strict";var n=0;function a(){return Math.pow(2,++n)}t.boolean=a(),t.booleanish=a(),t.overloadedBoolean=a(),t.number=a(),t.spaceSeparated=a(),t.commaSeparated=a(),t.commaOrSpaceSeparated=a()},73934:e=>{"use strict";e.exports=function(e){var t="string"===typeof e?e.charCodeAt(0):e;return t>=97&&t<=122||t>=65&&t<=90}},82140:(e,t)=>{"use strict";t.q=function(e){var t=String(e||n).trim();return t===n?[]:t.split(r)};var n="",a=" ",r=/[ \t\n\r\f]+/g},82719:e=>{"use strict";e.exports=JSON.parse('{"AElig":"\xc6","AMP":"&","Aacute":"\xc1","Acirc":"\xc2","Agrave":"\xc0","Aring":"\xc5","Atilde":"\xc3","Auml":"\xc4","COPY":"\xa9","Ccedil":"\xc7","ETH":"\xd0","Eacute":"\xc9","Ecirc":"\xca","Egrave":"\xc8","Euml":"\xcb","GT":">","Iacute":"\xcd","Icirc":"\xce","Igrave":"\xcc","Iuml":"\xcf","LT":"<","Ntilde":"\xd1","Oacute":"\xd3","Ocirc":"\xd4","Ograve":"\xd2","Oslash":"\xd8","Otilde":"\xd5","Ouml":"\xd6","QUOT":"\\"","REG":"\xae","THORN":"\xde","Uacute":"\xda","Ucirc":"\xdb","Ugrave":"\xd9","Uuml":"\xdc","Yacute":"\xdd","aacute":"\xe1","acirc":"\xe2","acute":"\xb4","aelig":"\xe6","agrave":"\xe0","amp":"&","aring":"\xe5","atilde":"\xe3","auml":"\xe4","brvbar":"\xa6","ccedil":"\xe7","cedil":"\xb8","cent":"\xa2","copy":"\xa9","curren":"\xa4","deg":"\xb0","divide":"\xf7","eacute":"\xe9","ecirc":"\xea","egrave":"\xe8","eth":"\xf0","euml":"\xeb","frac12":"\xbd","frac14":"\xbc","frac34":"\xbe","gt":">","iacute":"\xed","icirc":"\xee","iexcl":"\xa1","igrave":"\xec","iquest":"\xbf","iuml":"\xef","laquo":"\xab","lt":"<","macr":"\xaf","micro":"\xb5","middot":"\xb7","nbsp":"\xa0","not":"\xac","ntilde":"\xf1","oacute":"\xf3","ocirc":"\xf4","ograve":"\xf2","ordf":"\xaa","ordm":"\xba","oslash":"\xf8","otilde":"\xf5","ouml":"\xf6","para":"\xb6","plusmn":"\xb1","pound":"\xa3","quot":"\\"","raquo":"\xbb","reg":"\xae","sect":"\xa7","shy":"\xad","sup1":"\xb9","sup2":"\xb2","sup3":"\xb3","szlig":"\xdf","thorn":"\xfe","times":"\xd7","uacute":"\xfa","ucirc":"\xfb","ugrave":"\xf9","uml":"\xa8","uuml":"\xfc","yacute":"\xfd","yen":"\xa5","yuml":"\xff"}')},83851:(e,t,n)=>{"use strict";var a=n(71478);e.exports=a({space:"xlink",transform:function(e,t){return"xlink:"+t.slice(5).toLowerCase()},properties:{xLinkActuate:null,xLinkArcRole:null,xLinkHref:null,xLinkRole:null,xLinkShow:null,xLinkTitle:null,xLinkType:null}})},83991:e=>{"use strict";e.exports=function(e){var t="string"===typeof e?e.charCodeAt(0):e;return t>=97&&t<=102||t>=65&&t<=70||t>=48&&t<=57}},86598:(e,t,n)=>{"use strict";var a="object"===typeof globalThis?globalThis:"object"===typeof self?self:"object"===typeof window?window:"object"===typeof n.g?n.g:{},r=function(){var e="Prism"in a,t=e?a.Prism:void 0;return function(){e?a.Prism=t:delete a.Prism;e=void 0,t=void 0}}();a.Prism={manual:!0,disableWorkerMessageHandler:!0};var o=n(55942),l=n(72824),c=n(93915),i=n(33592),s=n(61993),u=n(22216),d=n(50683);r();var p={}.hasOwnProperty;function g(){}g.prototype=c;var m=new g;function f(e){if("function"!==typeof e||!e.displayName)throw new Error("Expected `function` for `grammar`, got `"+e+"`");void 0===m.languages[e.displayName]&&e(m)}e.exports=m,m.highlight=function(e,t){var n,a=c.highlight;if("string"!==typeof e)throw new Error("Expected `string` for `value`, got `"+e+"`");if("Object"===m.util.type(t))n=t,t=null;else{if("string"!==typeof t)throw new Error("Expected `string` for `name`, got `"+t+"`");if(!p.call(m.languages,t))throw new Error("Unknown language: `"+t+"` is not registered");n=m.languages[t]}return a.call(this,e,n,t)},m.register=f,m.alias=function(e,t){var n,a,r,o,l=m.languages,c=e;t&&((c={})[e]=t);for(n in c)for(r=(a="string"===typeof(a=c[n])?[a]:a).length,o=-1;++o{"use strict";e.exports=function(e,n){var a,r,o,l=e||"",c=n||"div",i={},s=0;for(;s{"use strict";var a=n(71478);e.exports=a({space:"xml",transform:function(e,t){return"xml:"+t.slice(3).toLowerCase()},properties:{xmlLang:null,xmlBase:null,xmlSpace:null}})},93915:(e,t,n)=>{var a=function(e){var t=/(?:^|\s)lang(?:uage)?-([\w-]+)(?=\s|$)/i,n=0,a={},r={manual:e.Prism&&e.Prism.manual,disableWorkerMessageHandler:e.Prism&&e.Prism.disableWorkerMessageHandler,util:{encode:function e(t){return t instanceof o?new o(t.type,e(t.content),t.alias):Array.isArray(t)?t.map(e):t.replace(/&/g,"&").replace(/=d.reach);S+=k.value.length,k=k.next){var A=k.value;if(t.length>e.length)return;if(!(A instanceof o)){var F,O=1;if(b){if(!(F=l(x,S,e,y))||F.index>=e.length)break;var N=F.index,C=F.index+F[0].length,j=S;for(j+=k.value.length;N>=j;)j+=(k=k.next).value.length;if(S=j-=k.value.length,k.value instanceof o)continue;for(var P=k;P!==t.tail&&(jd.reach&&(d.reach=z);var M=k.prev;if(_&&(M=s(t,M,_),S+=_.length),u(t,M,O),k=s(t,M,new o(p,h?r.tokenize(L,h):L,v,L)),E&&s(t,k,E),O>1){var T={cause:p+","+m,reach:z};c(e,t,n,k.prev,S,T),d&&T.reach>d.reach&&(d.reach=T.reach)}}}}}}function i(){var e={value:null,prev:null,next:null},t={value:null,prev:e,next:null};e.next=t,this.head=e,this.tail=t,this.length=0}function s(e,t,n){var a=t.next,r={value:n,prev:t,next:a};return t.next=r,a.prev=r,e.length++,r}function u(e,t,n){for(var a=t.next,r=0;r"+o.content+""},!e.document)return e.addEventListener?(r.disableWorkerMessageHandler||e.addEventListener("message",(function(t){var n=JSON.parse(t.data),a=n.language,o=n.code,l=n.immediateClose;e.postMessage(r.highlight(o,r.languages[a],a)),l&&e.close()}),!1),r):r;var d=r.util.currentScript();function p(){r.manual||r.highlightAll()}if(d&&(r.filename=d.src,d.hasAttribute("data-manual")&&(r.manual=!0)),!r.manual){var g=document.readyState;"loading"===g||"interactive"===g&&d&&d.defer?document.addEventListener("DOMContentLoaded",p):window.requestAnimationFrame?window.requestAnimationFrame(p):window.setTimeout(p,16)}return r}("undefined"!==typeof window?window:"undefined"!==typeof WorkerGlobalScope&&self instanceof WorkerGlobalScope?self:{});e.exports&&(e.exports=a),"undefined"!==typeof n.g&&(n.g.Prism=a)},94667:e=>{"use strict";e.exports=function(e){var t="string"===typeof e?e.charCodeAt(0):e;return t>=48&&t<=57}},96298:(e,t,n)=>{"use strict";n.d(t,{A:()=>z});var a=n(98587);function r(e,t){(null==t||t>e.length)&&(t=e.length);for(var n=0,a=Array(t);n1&&void 0!==arguments[1]?arguments[1]:{},n=arguments.length>2?arguments[2]:void 0;return function(e){if(0===e.length||1===e.length)return e;var t=e.join(".");return g[t]||(g[t]=function(e){var t=e.length;return 0===t||1===t?e:2===t?[e[0],e[1],"".concat(e[0],".").concat(e[1]),"".concat(e[1],".").concat(e[0])]:3===t?[e[0],e[1],e[2],"".concat(e[0],".").concat(e[1]),"".concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[0]),"".concat(e[1],".").concat(e[2]),"".concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[1]),"".concat(e[0],".").concat(e[1],".").concat(e[2]),"".concat(e[0],".").concat(e[2],".").concat(e[1]),"".concat(e[1],".").concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[0],".").concat(e[1]),"".concat(e[2],".").concat(e[1],".").concat(e[0])]:t>=4?[e[0],e[1],e[2],e[3],"".concat(e[0],".").concat(e[1]),"".concat(e[0],".").concat(e[2]),"".concat(e[0],".").concat(e[3]),"".concat(e[1],".").concat(e[0]),"".concat(e[1],".").concat(e[2]),"".concat(e[1],".").concat(e[3]),"".concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[1]),"".concat(e[2],".").concat(e[3]),"".concat(e[3],".").concat(e[0]),"".concat(e[3],".").concat(e[1]),"".concat(e[3],".").concat(e[2]),"".concat(e[0],".").concat(e[1],".").concat(e[2]),"".concat(e[0],".").concat(e[1],".").concat(e[3]),"".concat(e[0],".").concat(e[2],".").concat(e[1]),"".concat(e[0],".").concat(e[2],".").concat(e[3]),"".concat(e[0],".").concat(e[3],".").concat(e[1]),"".concat(e[0],".").concat(e[3],".").concat(e[2]),"".concat(e[1],".").concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[0],".").concat(e[3]),"".concat(e[1],".").concat(e[2],".").concat(e[0]),"".concat(e[1],".").concat(e[2],".").concat(e[3]),"".concat(e[1],".").concat(e[3],".").concat(e[0]),"".concat(e[1],".").concat(e[3],".").concat(e[2]),"".concat(e[2],".").concat(e[0],".").concat(e[1]),"".concat(e[2],".").concat(e[0],".").concat(e[3]),"".concat(e[2],".").concat(e[1],".").concat(e[0]),"".concat(e[2],".").concat(e[1],".").concat(e[3]),"".concat(e[2],".").concat(e[3],".").concat(e[0]),"".concat(e[2],".").concat(e[3],".").concat(e[1]),"".concat(e[3],".").concat(e[0],".").concat(e[1]),"".concat(e[3],".").concat(e[0],".").concat(e[2]),"".concat(e[3],".").concat(e[1],".").concat(e[0]),"".concat(e[3],".").concat(e[1],".").concat(e[2]),"".concat(e[3],".").concat(e[2],".").concat(e[0]),"".concat(e[3],".").concat(e[2],".").concat(e[1]),"".concat(e[0],".").concat(e[1],".").concat(e[2],".").concat(e[3]),"".concat(e[0],".").concat(e[1],".").concat(e[3],".").concat(e[2]),"".concat(e[0],".").concat(e[2],".").concat(e[1],".").concat(e[3]),"".concat(e[0],".").concat(e[2],".").concat(e[3],".").concat(e[1]),"".concat(e[0],".").concat(e[3],".").concat(e[1],".").concat(e[2]),"".concat(e[0],".").concat(e[3],".").concat(e[2],".").concat(e[1]),"".concat(e[1],".").concat(e[0],".").concat(e[2],".").concat(e[3]),"".concat(e[1],".").concat(e[0],".").concat(e[3],".").concat(e[2]),"".concat(e[1],".").concat(e[2],".").concat(e[0],".").concat(e[3]),"".concat(e[1],".").concat(e[2],".").concat(e[3],".").concat(e[0]),"".concat(e[1],".").concat(e[3],".").concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[3],".").concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[0],".").concat(e[1],".").concat(e[3]),"".concat(e[2],".").concat(e[0],".").concat(e[3],".").concat(e[1]),"".concat(e[2],".").concat(e[1],".").concat(e[0],".").concat(e[3]),"".concat(e[2],".").concat(e[1],".").concat(e[3],".").concat(e[0]),"".concat(e[2],".").concat(e[3],".").concat(e[0],".").concat(e[1]),"".concat(e[2],".").concat(e[3],".").concat(e[1],".").concat(e[0]),"".concat(e[3],".").concat(e[0],".").concat(e[1],".").concat(e[2]),"".concat(e[3],".").concat(e[0],".").concat(e[2],".").concat(e[1]),"".concat(e[3],".").concat(e[1],".").concat(e[0],".").concat(e[2]),"".concat(e[3],".").concat(e[1],".").concat(e[2],".").concat(e[0]),"".concat(e[3],".").concat(e[2],".").concat(e[0],".").concat(e[1]),"".concat(e[3],".").concat(e[2],".").concat(e[1],".").concat(e[0])]:void 0}(e)),g[t]}(e.filter((function(e){return"token"!==e}))).reduce((function(e,t){return p(p({},e),n[t])}),t)}function f(e){return e.join(" ")}function h(e){var t=e.node,n=e.stylesheet,a=e.style,r=void 0===a?{}:a,o=e.useInlineStyles,l=e.key,c=t.properties,i=t.type,d=t.tagName,g=t.value;if("text"===i)return g;if(d){var y,b=function(e,t){var n=0;return function(a){return n+=1,a.map((function(a,r){return h({node:a,stylesheet:e,useInlineStyles:t,key:"code-segment-".concat(n,"-").concat(r)})}))}}(n,o);if(o){var v=Object.keys(n).reduce((function(e,t){return t.split(".").forEach((function(t){e.includes(t)||e.push(t)})),e}),[]),w=c.className&&c.className.includes("token")?["token"]:[],x=c.className&&w.concat(c.className.filter((function(e){return!v.includes(e)})));y=p(p({},c),{},{className:f(x)||void 0,style:m(c.className,Object.assign({},c.style,r),n)})}else y=p(p({},c),{},{className:f(c.className)});var k=b(t.children);return s.createElement(d,(0,u.A)({key:l},y),k)}}var y=["language","children","style","customStyle","codeTagProps","useInlineStyles","showLineNumbers","showInlineLineNumbers","startingLineNumber","lineNumberContainerStyle","lineNumberStyle","wrapLines","wrapLongLines","lineProps","renderer","PreTag","CodeTag","code","astGenerator"];function b(e,t){var n=Object.keys(e);if(Object.getOwnPropertySymbols){var a=Object.getOwnPropertySymbols(e);t&&(a=a.filter((function(t){return Object.getOwnPropertyDescriptor(e,t).enumerable}))),n.push.apply(n,a)}return n}function v(e){for(var t=1;t1&&void 0!==arguments[1]?arguments[1]:[],n=arguments.length>2&&void 0!==arguments[2]?arguments[2]:[],a=0;a2&&void 0!==arguments[2]?arguments[2]:[];return t||s.length>0?function(e,o){return A({children:e,lineNumber:o,lineNumberStyle:c,largestLineNumber:l,showInlineLineNumbers:r,lineProps:n,className:arguments.length>2&&void 0!==arguments[2]?arguments[2]:[],showLineNumbers:a,wrapLongLines:i,wrapLines:t})}(e,o,s):function(e,t){if(a&&t&&r){var n=S(c,t,l);e.unshift(k(t,n))}return e}(e,o)}for(var f=function(){var e=u[g],t=e.children[0].value;if(t.match(w)){var n=t.split("\n");n.forEach((function(t,r){var l=a&&d.length+o,c={type:"text",value:"".concat(t,"\n")};if(0===r){var i=m(u.slice(p+1,g).concat(A({children:[c],className:e.properties.className})),l);d.push(i)}else if(r===n.length-1){var s=u[g+1]&&u[g+1].children&&u[g+1].children[0],f={type:"text",value:"".concat(t)};if(s){var h=A({children:[f],className:e.properties.className});u.splice(g+1,0,h)}else{var y=m([f],l,e.properties.className);d.push(y)}}else{var b=m([c],l,e.properties.className);d.push(b)}})),p=g}g++};g + * @author Lea Verou + * @namespace + * @public + */ diff --git a/ydb/core/viewer/monitoring/static/js/66824.abfa3f22.chunk.js b/ydb/core/viewer/monitoring/static/js/66824.abfa3f22.chunk.js new file mode 100644 index 000000000000..91c979a8f521 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/66824.abfa3f22.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[66824],{66824:(e,a,s)=>{s.d(a,{default:()=>r});var b=s(78029);const r=s.n(b)()},78029:e=>{function a(e){e.languages.birb=e.languages.extend("clike",{string:{pattern:/r?("|')(?:\\.|(?!\1)[^\\])*\1/,greedy:!0},"class-name":[/\b[A-Z](?:[\d_]*[a-zA-Z]\w*)?\b/,/\b(?:[A-Z]\w*|(?!(?:var|void)\b)[a-z]\w*)(?=\s+\w+\s*[;,=()])/],keyword:/\b(?:assert|break|case|class|const|default|else|enum|final|follows|for|grab|if|nest|new|next|noSeeb|return|static|switch|throw|var|void|while)\b/,operator:/\+\+|--|&&|\|\||<<=?|>>=?|~(?:\/=?)?|[+\-*\/%&^|=!<>]=?|\?|:/,variable:/\b[a-z_]\w*\b/}),e.languages.insertBefore("birb","function",{metadata:{pattern:/<\w+>/,greedy:!0,alias:"symbol"}})}e.exports=a,a.displayName="birb",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/67105.3413451f.chunk.js b/ydb/core/viewer/monitoring/static/js/67105.3413451f.chunk.js new file mode 100644 index 000000000000..a297eff5e34d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/67105.3413451f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[67105],{15182:e=>{function n(e){e.languages.vim={string:/"(?:[^"\\\r\n]|\\.)*"|'(?:[^'\r\n]|'')*'/,comment:/".*/,function:/\b\w+(?=\()/,keyword:/\b(?:N|Next|P|Print|X|XMLent|XMLns|ab|abbreviate|abc|abclear|abo|aboveleft|al|all|ar|arga|argadd|argd|argdelete|argdo|arge|argedit|argg|argglobal|argl|arglocal|args|argu|argument|as|ascii|b|bN|bNext|ba|bad|badd|ball|bd|bdelete|be|bel|belowright|bf|bfirst|bl|blast|bm|bmodified|bn|bnext|bo|botright|bp|bprevious|br|brea|break|breaka|breakadd|breakd|breakdel|breakl|breaklist|brewind|bro|browse|bufdo|buffer|buffers|bun|bunload|bw|bwipeout|c|cN|cNext|cNfcNfile|ca|cabbrev|cabc|cabclear|cad|caddb|caddbuffer|caddexpr|caddf|caddfile|cal|call|cat|catch|cb|cbuffer|cc|ccl|cclose|cd|ce|center|cex|cexpr|cf|cfile|cfir|cfirst|cg|cgetb|cgetbuffer|cgete|cgetexpr|cgetfile|change|changes|chd|chdir|che|checkpath|checkt|checktime|cl|cla|clast|clist|clo|close|cmapc|cmapclear|cn|cnew|cnewer|cnext|cnf|cnfile|cnorea|cnoreabbrev|co|col|colder|colo|colorscheme|comc|comclear|comp|compiler|con|conf|confirm|continue|cope|copen|copy|cp|cpf|cpfile|cprevious|cq|cquit|cr|crewind|cu|cuna|cunabbrev|cunmap|cw|cwindow|d|debugg|debuggreedy|delc|delcommand|delete|delf|delfunction|delm|delmarks|di|diffg|diffget|diffoff|diffpatch|diffpu|diffput|diffsplit|diffthis|diffu|diffupdate|dig|digraphs|display|dj|djump|dl|dlist|dr|drop|ds|dsearch|dsp|dsplit|e|earlier|echoe|echoerr|echom|echomsg|echon|edit|el|else|elsei|elseif|em|emenu|en|endf|endfo|endfor|endfun|endfunction|endif|endt|endtry|endw|endwhile|ene|enew|ex|exi|exit|exu|exusage|f|file|files|filetype|fin|fina|finally|find|fini|finish|fir|first|fix|fixdel|fo|fold|foldc|foldclose|foldd|folddoc|folddoclosed|folddoopen|foldo|foldopen|for|fu|fun|function|go|goto|gr|grep|grepa|grepadd|h|ha|hardcopy|help|helpf|helpfind|helpg|helpgrep|helpt|helptags|hid|hide|his|history|ia|iabbrev|iabc|iabclear|if|ij|ijump|il|ilist|imapc|imapclear|in|inorea|inoreabbrev|isearch|isp|isplit|iu|iuna|iunabbrev|iunmap|j|join|ju|jumps|k|kee|keepalt|keepj|keepjumps|keepmarks|l|lN|lNext|lNf|lNfile|la|lad|laddb|laddbuffer|laddexpr|laddf|laddfile|lan|language|last|later|lb|lbuffer|lc|lcd|lch|lchdir|lcl|lclose|left|lefta|leftabove|let|lex|lexpr|lf|lfile|lfir|lfirst|lg|lgetb|lgetbuffer|lgete|lgetexpr|lgetfile|lgr|lgrep|lgrepa|lgrepadd|lh|lhelpgrep|list|ll|lla|llast|lli|llist|lm|lmak|lmake|lmap|lmapc|lmapclear|ln|lne|lnew|lnewer|lnext|lnf|lnfile|lnoremap|lo|loadview|loc|lockmarks|lockv|lockvar|lol|lolder|lop|lopen|lp|lpf|lpfile|lprevious|lr|lrewind|ls|lt|ltag|lu|lunmap|lv|lvimgrep|lvimgrepa|lvimgrepadd|lw|lwindow|m|ma|mak|make|mark|marks|mat|match|menut|menutranslate|mk|mkexrc|mks|mksession|mksp|mkspell|mkv|mkvie|mkview|mkvimrc|mod|mode|move|mz|mzf|mzfile|mzscheme|n|nbkey|new|next|nmapc|nmapclear|noh|nohlsearch|norea|noreabbrev|nu|number|nun|nunmap|o|omapc|omapclear|on|only|open|opt|options|ou|ounmap|p|pc|pclose|pe|ped|pedit|perl|perld|perldo|po|pop|popu|popup|pp|ppop|pre|preserve|prev|previous|print|prof|profd|profdel|profile|promptf|promptfind|promptr|promptrepl|ps|psearch|ptN|ptNext|pta|ptag|ptf|ptfirst|ptj|ptjump|ptl|ptlast|ptn|ptnext|ptp|ptprevious|ptr|ptrewind|pts|ptselect|pu|put|pw|pwd|py|pyf|pyfile|python|q|qa|qall|quit|quita|quitall|r|read|rec|recover|red|redi|redir|redo|redr|redraw|redraws|redrawstatus|reg|registers|res|resize|ret|retab|retu|return|rew|rewind|ri|right|rightb|rightbelow|ru|rub|ruby|rubyd|rubydo|rubyf|rubyfile|runtime|rv|rviminfo|sN|sNext|sa|sal|sall|san|sandbox|sargument|sav|saveas|sb|sbN|sbNext|sba|sball|sbf|sbfirst|sbl|sblast|sbm|sbmodified|sbn|sbnext|sbp|sbprevious|sbr|sbrewind|sbuffer|scrip|scripte|scriptencoding|scriptnames|se|set|setf|setfiletype|setg|setglobal|setl|setlocal|sf|sfind|sfir|sfirst|sh|shell|sign|sil|silent|sim|simalt|sl|sla|slast|sleep|sm|smagic|smap|smapc|smapclear|sme|smenu|sn|snext|sni|sniff|sno|snomagic|snor|snoremap|snoreme|snoremenu|so|sor|sort|source|sp|spe|spelld|spelldump|spellgood|spelli|spellinfo|spellr|spellrepall|spellu|spellundo|spellw|spellwrong|split|spr|sprevious|sre|srewind|st|sta|stag|star|startg|startgreplace|startinsert|startr|startreplace|stj|stjump|stop|stopi|stopinsert|sts|stselect|sun|sunhide|sunm|sunmap|sus|suspend|sv|sview|syncbind|t|tN|tNext|ta|tab|tabN|tabNext|tabc|tabclose|tabd|tabdo|tabe|tabedit|tabf|tabfind|tabfir|tabfirst|tabl|tablast|tabm|tabmove|tabn|tabnew|tabnext|tabo|tabonly|tabp|tabprevious|tabr|tabrewind|tabs|tag|tags|tc|tcl|tcld|tcldo|tclf|tclfile|te|tearoff|tf|tfirst|th|throw|tj|tjump|tl|tlast|tm|tmenu|tn|tnext|to|topleft|tp|tprevious|tr|trewind|try|ts|tselect|tu|tunmenu|u|una|unabbreviate|undo|undoj|undojoin|undol|undolist|unh|unhide|unlet|unlo|unlockvar|unm|unmap|up|update|ve|verb|verbose|version|vert|vertical|vi|vie|view|vim|vimgrep|vimgrepa|vimgrepadd|visual|viu|viusage|vmapc|vmapclear|vne|vnew|vs|vsplit|vu|vunmap|w|wN|wNext|wa|wall|wh|while|win|winc|wincmd|windo|winp|winpos|winsize|wn|wnext|wp|wprevious|wq|wqa|wqall|write|ws|wsverb|wv|wviminfo|x|xa|xall|xit|xm|xmap|xmapc|xmapclear|xme|xmenu|xn|xnoremap|xnoreme|xnoremenu|xu|xunmap|y|yank)\b/,builtin:/\b(?:acd|ai|akm|aleph|allowrevins|altkeymap|ambiwidth|ambw|anti|antialias|arab|arabic|arabicshape|ari|arshape|autochdir|autocmd|autoindent|autoread|autowrite|autowriteall|aw|awa|background|backspace|backup|backupcopy|backupdir|backupext|backupskip|balloondelay|ballooneval|balloonexpr|bdir|bdlay|beval|bex|bexpr|bg|bh|bin|binary|biosk|bioskey|bk|bkc|bomb|breakat|brk|browsedir|bs|bsdir|bsk|bt|bufhidden|buflisted|buftype|casemap|ccv|cdpath|cedit|cfu|ch|charconvert|ci|cin|cindent|cink|cinkeys|cino|cinoptions|cinw|cinwords|clipboard|cmdheight|cmdwinheight|cmp|cms|columns|com|comments|commentstring|compatible|complete|completefunc|completeopt|consk|conskey|copyindent|cot|cpo|cpoptions|cpt|cscopepathcomp|cscopeprg|cscopequickfix|cscopetag|cscopetagorder|cscopeverbose|cspc|csprg|csqf|cst|csto|csverb|cuc|cul|cursorcolumn|cursorline|cwh|debug|deco|def|define|delcombine|dex|dg|dict|dictionary|diff|diffexpr|diffopt|digraph|dip|dir|directory|dy|ea|ead|eadirection|eb|ed|edcompatible|ef|efm|ei|ek|enc|encoding|endofline|eol|ep|equalalways|equalprg|errorbells|errorfile|errorformat|esckeys|et|eventignore|expandtab|exrc|fcl|fcs|fdc|fde|fdi|fdl|fdls|fdm|fdn|fdo|fdt|fen|fenc|fencs|fex|ff|ffs|fileencoding|fileencodings|fileformat|fileformats|fillchars|fk|fkmap|flp|fml|fmr|foldcolumn|foldenable|foldexpr|foldignore|foldlevel|foldlevelstart|foldmarker|foldmethod|foldminlines|foldnestmax|foldtext|formatexpr|formatlistpat|formatoptions|formatprg|fp|fs|fsync|ft|gcr|gd|gdefault|gfm|gfn|gfs|gfw|ghr|gp|grepformat|grepprg|gtl|gtt|guicursor|guifont|guifontset|guifontwide|guiheadroom|guioptions|guipty|guitablabel|guitabtooltip|helpfile|helpheight|helplang|hf|hh|hi|hidden|highlight|hk|hkmap|hkmapp|hkp|hl|hlg|hls|hlsearch|ic|icon|iconstring|ignorecase|im|imactivatekey|imak|imc|imcmdline|imd|imdisable|imi|iminsert|ims|imsearch|inc|include|includeexpr|incsearch|inde|indentexpr|indentkeys|indk|inex|inf|infercase|insertmode|invacd|invai|invakm|invallowrevins|invaltkeymap|invanti|invantialias|invar|invarab|invarabic|invarabicshape|invari|invarshape|invautochdir|invautoindent|invautoread|invautowrite|invautowriteall|invaw|invawa|invbackup|invballooneval|invbeval|invbin|invbinary|invbiosk|invbioskey|invbk|invbl|invbomb|invbuflisted|invcf|invci|invcin|invcindent|invcompatible|invconfirm|invconsk|invconskey|invcopyindent|invcp|invcscopetag|invcscopeverbose|invcst|invcsverb|invcuc|invcul|invcursorcolumn|invcursorline|invdeco|invdelcombine|invdg|invdiff|invdigraph|invdisable|invea|inveb|inved|invedcompatible|invek|invendofline|inveol|invequalalways|inverrorbells|invesckeys|invet|invex|invexpandtab|invexrc|invfen|invfk|invfkmap|invfoldenable|invgd|invgdefault|invguipty|invhid|invhidden|invhk|invhkmap|invhkmapp|invhkp|invhls|invhlsearch|invic|invicon|invignorecase|invim|invimc|invimcmdline|invimd|invincsearch|invinf|invinfercase|invinsertmode|invis|invjoinspaces|invjs|invlazyredraw|invlbr|invlinebreak|invlisp|invlist|invloadplugins|invlpl|invlz|invma|invmacatsui|invmagic|invmh|invml|invmod|invmodeline|invmodifiable|invmodified|invmore|invmousef|invmousefocus|invmousehide|invnu|invnumber|invodev|invopendevice|invpaste|invpi|invpreserveindent|invpreviewwindow|invprompt|invpvw|invreadonly|invremap|invrestorescreen|invrevins|invri|invrightleft|invrightleftcmd|invrl|invrlc|invro|invrs|invru|invruler|invsb|invsc|invscb|invscrollbind|invscs|invsecure|invsft|invshellslash|invshelltemp|invshiftround|invshortname|invshowcmd|invshowfulltag|invshowmatch|invshowmode|invsi|invsm|invsmartcase|invsmartindent|invsmarttab|invsmd|invsn|invsol|invspell|invsplitbelow|invsplitright|invspr|invsr|invssl|invsta|invstartofline|invstmp|invswapfile|invswf|invta|invtagbsearch|invtagrelative|invtagstack|invtbi|invtbidi|invtbs|invtermbidi|invterse|invtextauto|invtextmode|invtf|invtgst|invtildeop|invtimeout|invtitle|invto|invtop|invtr|invttimeout|invttybuiltin|invttyfast|invtx|invvb|invvisualbell|invwa|invwarn|invwb|invweirdinvert|invwfh|invwfw|invwildmenu|invwinfixheight|invwinfixwidth|invwiv|invwmnu|invwrap|invwrapscan|invwrite|invwriteany|invwritebackup|invws|isf|isfname|isi|isident|isk|iskeyword|isprint|joinspaces|js|key|keymap|keymodel|keywordprg|km|kmp|kp|langmap|langmenu|laststatus|lazyredraw|lbr|lcs|linebreak|lines|linespace|lisp|lispwords|listchars|loadplugins|lpl|lsp|lz|macatsui|magic|makeef|makeprg|matchpairs|matchtime|maxcombine|maxfuncdepth|maxmapdepth|maxmem|maxmempattern|maxmemtot|mco|mef|menuitems|mfd|mh|mis|mkspellmem|ml|mls|mm|mmd|mmp|mmt|modeline|modelines|modifiable|modified|more|mouse|mousef|mousefocus|mousehide|mousem|mousemodel|mouses|mouseshape|mouset|mousetime|mp|mps|msm|mzq|mzquantum|nf|noacd|noai|noakm|noallowrevins|noaltkeymap|noanti|noantialias|noar|noarab|noarabic|noarabicshape|noari|noarshape|noautochdir|noautoindent|noautoread|noautowrite|noautowriteall|noaw|noawa|nobackup|noballooneval|nobeval|nobin|nobinary|nobiosk|nobioskey|nobk|nobl|nobomb|nobuflisted|nocf|noci|nocin|nocindent|nocompatible|noconfirm|noconsk|noconskey|nocopyindent|nocp|nocscopetag|nocscopeverbose|nocst|nocsverb|nocuc|nocul|nocursorcolumn|nocursorline|nodeco|nodelcombine|nodg|nodiff|nodigraph|nodisable|noea|noeb|noed|noedcompatible|noek|noendofline|noeol|noequalalways|noerrorbells|noesckeys|noet|noex|noexpandtab|noexrc|nofen|nofk|nofkmap|nofoldenable|nogd|nogdefault|noguipty|nohid|nohidden|nohk|nohkmap|nohkmapp|nohkp|nohls|noic|noicon|noignorecase|noim|noimc|noimcmdline|noimd|noincsearch|noinf|noinfercase|noinsertmode|nois|nojoinspaces|nojs|nolazyredraw|nolbr|nolinebreak|nolisp|nolist|noloadplugins|nolpl|nolz|noma|nomacatsui|nomagic|nomh|noml|nomod|nomodeline|nomodifiable|nomodified|nomore|nomousef|nomousefocus|nomousehide|nonu|nonumber|noodev|noopendevice|nopaste|nopi|nopreserveindent|nopreviewwindow|noprompt|nopvw|noreadonly|noremap|norestorescreen|norevins|nori|norightleft|norightleftcmd|norl|norlc|noro|nors|noru|noruler|nosb|nosc|noscb|noscrollbind|noscs|nosecure|nosft|noshellslash|noshelltemp|noshiftround|noshortname|noshowcmd|noshowfulltag|noshowmatch|noshowmode|nosi|nosm|nosmartcase|nosmartindent|nosmarttab|nosmd|nosn|nosol|nospell|nosplitbelow|nosplitright|nospr|nosr|nossl|nosta|nostartofline|nostmp|noswapfile|noswf|nota|notagbsearch|notagrelative|notagstack|notbi|notbidi|notbs|notermbidi|noterse|notextauto|notextmode|notf|notgst|notildeop|notimeout|notitle|noto|notop|notr|nottimeout|nottybuiltin|nottyfast|notx|novb|novisualbell|nowa|nowarn|nowb|noweirdinvert|nowfh|nowfw|nowildmenu|nowinfixheight|nowinfixwidth|nowiv|nowmnu|nowrap|nowrapscan|nowrite|nowriteany|nowritebackup|nows|nrformats|numberwidth|nuw|odev|oft|ofu|omnifunc|opendevice|operatorfunc|opfunc|osfiletype|pa|para|paragraphs|paste|pastetoggle|patchexpr|patchmode|path|pdev|penc|pex|pexpr|pfn|ph|pheader|pi|pm|pmbcs|pmbfn|popt|preserveindent|previewheight|previewwindow|printdevice|printencoding|printexpr|printfont|printheader|printmbcharset|printmbfont|printoptions|prompt|pt|pumheight|pvh|pvw|qe|quoteescape|readonly|remap|report|restorescreen|revins|rightleft|rightleftcmd|rl|rlc|ro|rs|rtp|ruf|ruler|rulerformat|runtimepath|sbo|sc|scb|scr|scroll|scrollbind|scrolljump|scrolloff|scrollopt|scs|sect|sections|secure|sel|selection|selectmode|sessionoptions|sft|shcf|shellcmdflag|shellpipe|shellquote|shellredir|shellslash|shelltemp|shelltype|shellxquote|shiftround|shiftwidth|shm|shortmess|shortname|showbreak|showcmd|showfulltag|showmatch|showmode|showtabline|shq|si|sidescroll|sidescrolloff|siso|sj|slm|smartcase|smartindent|smarttab|smc|smd|softtabstop|sol|spc|spell|spellcapcheck|spellfile|spelllang|spellsuggest|spf|spl|splitbelow|splitright|sps|sr|srr|ss|ssl|ssop|stal|startofline|statusline|stl|stmp|su|sua|suffixes|suffixesadd|sw|swapfile|swapsync|swb|swf|switchbuf|sws|sxq|syn|synmaxcol|syntax|t_AB|t_AF|t_AL|t_CS|t_CV|t_Ce|t_Co|t_Cs|t_DL|t_EI|t_F1|t_F2|t_F3|t_F4|t_F5|t_F6|t_F7|t_F8|t_F9|t_IE|t_IS|t_K1|t_K3|t_K4|t_K5|t_K6|t_K7|t_K8|t_K9|t_KA|t_KB|t_KC|t_KD|t_KE|t_KF|t_KG|t_KH|t_KI|t_KJ|t_KK|t_KL|t_RI|t_RV|t_SI|t_Sb|t_Sf|t_WP|t_WS|t_ZH|t_ZR|t_al|t_bc|t_cd|t_ce|t_cl|t_cm|t_cs|t_da|t_db|t_dl|t_fs|t_k1|t_k2|t_k3|t_k4|t_k5|t_k6|t_k7|t_k8|t_k9|t_kB|t_kD|t_kI|t_kN|t_kP|t_kb|t_kd|t_ke|t_kh|t_kl|t_kr|t_ks|t_ku|t_le|t_mb|t_md|t_me|t_mr|t_ms|t_nd|t_op|t_se|t_so|t_sr|t_te|t_ti|t_ts|t_ue|t_us|t_ut|t_vb|t_ve|t_vi|t_vs|t_xs|tabline|tabpagemax|tabstop|tagbsearch|taglength|tagrelative|tagstack|tal|tb|tbi|tbidi|tbis|tbs|tenc|term|termbidi|termencoding|terse|textauto|textmode|textwidth|tgst|thesaurus|tildeop|timeout|timeoutlen|title|titlelen|titleold|titlestring|toolbar|toolbariconsize|top|tpm|tsl|tsr|ttimeout|ttimeoutlen|ttm|tty|ttybuiltin|ttyfast|ttym|ttymouse|ttyscroll|ttytype|tw|tx|uc|ul|undolevels|updatecount|updatetime|ut|vb|vbs|vdir|verbosefile|vfile|viewdir|viewoptions|viminfo|virtualedit|visualbell|vop|wak|warn|wb|wc|wcm|wd|weirdinvert|wfh|wfw|whichwrap|wi|wig|wildchar|wildcharm|wildignore|wildmenu|wildmode|wildoptions|wim|winaltkeys|window|winfixheight|winfixwidth|winheight|winminheight|winminwidth|winwidth|wiv|wiw|wm|wmh|wmnu|wmw|wop|wrap|wrapmargin|wrapscan|writeany|writebackup|writedelay|ww)\b/,number:/\b(?:0x[\da-f]+|\d+(?:\.\d+)?)\b/i,operator:/\|\||&&|[-+.]=?|[=!](?:[=~][#?]?)?|[<>]=?[#?]?|[*\/%?]|\b(?:is(?:not)?)\b/,punctuation:/[{}[\](),;:]/}}e.exports=n,n.displayName="vim",n.aliases=[]},67105:(e,n,i)=>{i.d(n,{default:()=>o});var t=i(15182);const o=i.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/67191.46b77437.chunk.js b/ydb/core/viewer/monitoring/static/js/67191.46b77437.chunk.js new file mode 100644 index 000000000000..50c6977db10e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/67191.46b77437.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[67191],{48142:E=>{function N(E){E.languages.abap={comment:/^\*.*/m,string:/(`|')(?:\\.|(?!\1)[^\\\r\n])*\1/,"string-template":{pattern:/([|}])(?:\\.|[^\\|{\r\n])*(?=[|{])/,lookbehind:!0,alias:"string"},"eol-comment":{pattern:/(^|\s)".*/m,lookbehind:!0,alias:"comment"},keyword:{pattern:/(\s|\.|^)(?:SCIENTIFIC_WITH_LEADING_ZERO|SCALE_PRESERVING_SCIENTIFIC|RMC_COMMUNICATION_FAILURE|END-ENHANCEMENT-SECTION|MULTIPLY-CORRESPONDING|SUBTRACT-CORRESPONDING|VERIFICATION-MESSAGE|DIVIDE-CORRESPONDING|ENHANCEMENT-SECTION|CURRENCY_CONVERSION|RMC_SYSTEM_FAILURE|START-OF-SELECTION|MOVE-CORRESPONDING|RMC_INVALID_STATUS|CUSTOMER-FUNCTION|END-OF-DEFINITION|ENHANCEMENT-POINT|SYSTEM-EXCEPTIONS|ADD-CORRESPONDING|SCALE_PRESERVING|SELECTION-SCREEN|CURSOR-SELECTION|END-OF-SELECTION|LOAD-OF-PROGRAM|SCROLL-BOUNDARY|SELECTION-TABLE|EXCEPTION-TABLE|IMPLEMENTATIONS|PARAMETER-TABLE|RIGHT-JUSTIFIED|UNIT_CONVERSION|AUTHORITY-CHECK|LIST-PROCESSING|SIGN_AS_POSTFIX|COL_BACKGROUND|IMPLEMENTATION|INTERFACE-POOL|TRANSFORMATION|IDENTIFICATION|ENDENHANCEMENT|LINE-SELECTION|INITIALIZATION|LEFT-JUSTIFIED|SELECT-OPTIONS|SELECTION-SETS|COMMUNICATION|CORRESPONDING|DECIMAL_SHIFT|PRINT-CONTROL|VALUE-REQUEST|CHAIN-REQUEST|FUNCTION-POOL|FIELD-SYMBOLS|FUNCTIONALITY|INVERTED-DATE|SELECTION-SET|CLASS-METHODS|OUTPUT-LENGTH|CLASS-CODING|COL_NEGATIVE|ERRORMESSAGE|FIELD-GROUPS|HELP-REQUEST|NO-EXTENSION|NO-TOPOFPAGE|REDEFINITION|DISPLAY-MODE|ENDINTERFACE|EXIT-COMMAND|FIELD-SYMBOL|NO-SCROLLING|SHORTDUMP-ID|ACCESSPOLICY|CLASS-EVENTS|COL_POSITIVE|DECLARATIONS|ENHANCEMENTS|FILTER-TABLE|SWITCHSTATES|SYNTAX-CHECK|TRANSPORTING|ASYNCHRONOUS|SYNTAX-TRACE|TOKENIZATION|USER-COMMAND|WITH-HEADING|ABAP-SOURCE|BREAK-POINT|CHAIN-INPUT|COMPRESSION|FIXED-POINT|NEW-SECTION|NON-UNICODE|OCCURRENCES|RESPONSIBLE|SYSTEM-CALL|TRACE-TABLE|ABBREVIATED|CHAR-TO-HEX|END-OF-FILE|ENDFUNCTION|ENVIRONMENT|ASSOCIATION|COL_HEADING|EDITOR-CALL|END-OF-PAGE|ENGINEERING|IMPLEMENTED|INTENSIFIED|RADIOBUTTON|SYSTEM-EXIT|TOP-OF-PAGE|TRANSACTION|APPLICATION|CONCATENATE|DESTINATION|ENHANCEMENT|IMMEDIATELY|NO-GROUPING|PRECOMPILED|REPLACEMENT|TITLE-LINES|ACTIVATION|BYTE-ORDER|CLASS-POOL|CONNECTION|CONVERSION|DEFINITION|DEPARTMENT|EXPIRATION|INHERITING|MESSAGE-ID|NO-HEADING|PERFORMING|QUEUE-ONLY|RIGHTSPACE|SCIENTIFIC|STATUSINFO|STRUCTURES|SYNCPOINTS|WITH-TITLE|ATTRIBUTES|BOUNDARIES|CLASS-DATA|COL_NORMAL|DD\/MM\/YYYY|DESCENDING|INTERFACES|LINE-COUNT|MM\/DD\/YYYY|NON-UNIQUE|PRESERVING|SELECTIONS|STATEMENTS|SUBROUTINE|TRUNCATION|TYPE-POOLS|ARITHMETIC|BACKGROUND|ENDPROVIDE|EXCEPTIONS|IDENTIFIER|INDEX-LINE|OBLIGATORY|PARAMETERS|PERCENTAGE|PUSHBUTTON|RESOLUTION|COMPONENTS|DEALLOCATE|DISCONNECT|DUPLICATES|FIRST-LINE|HEAD-LINES|NO-DISPLAY|OCCURRENCE|RESPECTING|RETURNCODE|SUBMATCHES|TRACE-FILE|ASCENDING|BYPASSING|ENDMODULE|EXCEPTION|EXCLUDING|EXPORTING|INCREMENT|MATCHCODE|PARAMETER|PARTIALLY|PREFERRED|REFERENCE|REPLACING|RETURNING|SELECTION|SEPARATED|SPECIFIED|STATEMENT|TIMESTAMP|TYPE-POOL|ACCEPTING|APPENDAGE|ASSIGNING|COL_GROUP|COMPARING|CONSTANTS|DANGEROUS|IMPORTING|INSTANCES|LEFTSPACE|LOG-POINT|QUICKINFO|READ-ONLY|SCROLLING|SQLSCRIPT|STEP-LOOP|TOP-LINES|TRANSLATE|APPENDING|AUTHORITY|CHARACTER|COMPONENT|CONDITION|DIRECTORY|DUPLICATE|MESSAGING|RECEIVING|SUBSCREEN|ACCORDING|COL_TOTAL|END-LINES|ENDMETHOD|ENDSELECT|EXPANDING|EXTENSION|INCLUDING|INFOTYPES|INTERFACE|INTERVALS|LINE-SIZE|PF-STATUS|PROCEDURE|PROTECTED|REQUESTED|RESUMABLE|RIGHTPLUS|SAP-SPOOL|SECONDARY|STRUCTURE|SUBSTRING|TABLEVIEW|NUMOFCHAR|ADJACENT|ANALYSIS|ASSIGNED|BACKWARD|CHANNELS|CHECKBOX|CONTINUE|CRITICAL|DATAINFO|DD\/MM\/YY|DURATION|ENCODING|ENDCLASS|FUNCTION|LEFTPLUS|LINEFEED|MM\/DD\/YY|OVERFLOW|RECEIVED|SKIPPING|SORTABLE|STANDARD|SUBTRACT|SUPPRESS|TABSTRIP|TITLEBAR|TRUNCATE|UNASSIGN|WHENEVER|ANALYZER|COALESCE|COMMENTS|CONDENSE|DECIMALS|DEFERRED|ENDWHILE|EXPLICIT|KEYWORDS|MESSAGES|POSITION|PRIORITY|RECEIVER|RENAMING|TIMEZONE|TRAILING|ALLOCATE|CENTERED|CIRCULAR|CONTROLS|CURRENCY|DELETING|DESCRIBE|DISTANCE|ENDCATCH|EXPONENT|EXTENDED|GENERATE|IGNORING|INCLUDES|INTERNAL|MAJOR-ID|MODIFIER|NEW-LINE|OPTIONAL|PROPERTY|ROLLBACK|STARTING|SUPPLIED|ABSTRACT|CHANGING|CONTEXTS|CREATING|CUSTOMER|DATABASE|DAYLIGHT|DEFINING|DISTINCT|DIVISION|ENABLING|ENDCHAIN|ESCAPING|HARMLESS|IMPLICIT|INACTIVE|LANGUAGE|MINOR-ID|MULTIPLY|NEW-PAGE|NO-TITLE|POS_HIGH|SEPARATE|TEXTPOOL|TRANSFER|SELECTOR|DBMAXLEN|ITERATOR|ARCHIVE|BIT-XOR|BYTE-CO|COLLECT|COMMENT|CURRENT|DEFAULT|DISPLAY|ENDFORM|EXTRACT|LEADING|LISTBOX|LOCATOR|MEMBERS|METHODS|NESTING|POS_LOW|PROCESS|PROVIDE|RAISING|RESERVE|SECONDS|SUMMARY|VISIBLE|BETWEEN|BIT-AND|BYTE-CS|CLEANUP|COMPUTE|CONTROL|CONVERT|DATASET|ENDCASE|FORWARD|HEADERS|HOTSPOT|INCLUDE|INVERSE|KEEPING|NO-ZERO|OBJECTS|OVERLAY|PADDING|PATTERN|PROGRAM|REFRESH|SECTION|SUMMING|TESTING|VERSION|WINDOWS|WITHOUT|BIT-NOT|BYTE-CA|BYTE-NA|CASTING|CONTEXT|COUNTRY|DYNAMIC|ENABLED|ENDLOOP|EXECUTE|FRIENDS|HANDLER|HEADING|INITIAL|\*-INPUT|LOGFILE|MAXIMUM|MINIMUM|NO-GAPS|NO-SIGN|PRAGMAS|PRIMARY|PRIVATE|REDUCED|REPLACE|REQUEST|RESULTS|UNICODE|WARNING|ALIASES|BYTE-CN|BYTE-NS|CALLING|COL_KEY|COLUMNS|CONNECT|ENDEXEC|ENTRIES|EXCLUDE|FILTERS|FURTHER|HELP-ID|LOGICAL|MAPPING|MESSAGE|NAMETAB|OPTIONS|PACKAGE|PERFORM|RECEIVE|STATICS|VARYING|BINDING|CHARLEN|GREATER|XSTRLEN|ACCEPT|APPEND|DETAIL|ELSEIF|ENDING|ENDTRY|FORMAT|FRAMES|GIVING|HASHED|HEADER|IMPORT|INSERT|MARGIN|MODULE|NATIVE|OBJECT|OFFSET|REMOTE|RESUME|SAVING|SIMPLE|SUBMIT|TABBED|TOKENS|UNIQUE|UNPACK|UPDATE|WINDOW|YELLOW|ACTUAL|ASPECT|CENTER|CURSOR|DELETE|DIALOG|DIVIDE|DURING|ERRORS|EVENTS|EXTEND|FILTER|HANDLE|HAVING|IGNORE|LITTLE|MEMORY|NO-GAP|OCCURS|OPTION|PERSON|PLACES|PUBLIC|REDUCE|REPORT|RESULT|SINGLE|SORTED|SWITCH|SYNTAX|TARGET|VALUES|WRITER|ASSERT|BLOCKS|BOUNDS|BUFFER|CHANGE|COLUMN|COMMIT|CONCAT|COPIES|CREATE|DDMMYY|DEFINE|ENDIAN|ESCAPE|EXPAND|KERNEL|LAYOUT|LEGACY|LEVELS|MMDDYY|NUMBER|OUTPUT|RANGES|READER|RETURN|SCREEN|SEARCH|SELECT|SHARED|SOURCE|STABLE|STATIC|SUBKEY|SUFFIX|TABLES|UNWIND|YYMMDD|ASSIGN|BACKUP|BEFORE|BINARY|BIT-OR|BLANKS|CLIENT|CODING|COMMON|DEMAND|DYNPRO|EXCEPT|EXISTS|EXPORT|FIELDS|GLOBAL|GROUPS|LENGTH|LOCALE|MEDIUM|METHOD|MODIFY|NESTED|OTHERS|REJECT|SCROLL|SUPPLY|SYMBOL|ENDFOR|STRLEN|ALIGN|BEGIN|BOUND|ENDAT|ENTRY|EVENT|FINAL|FLUSH|GRANT|INNER|SHORT|USING|WRITE|AFTER|BLACK|BLOCK|CLOCK|COLOR|COUNT|DUMMY|EMPTY|ENDDO|ENDON|GREEN|INDEX|INOUT|LEAVE|LEVEL|LINES|MODIF|ORDER|OUTER|RANGE|RESET|RETRY|RIGHT|SMART|SPLIT|STYLE|TABLE|THROW|UNDER|UNTIL|UPPER|UTF-8|WHERE|ALIAS|BLANK|CLEAR|CLOSE|EXACT|FETCH|FIRST|FOUND|GROUP|LLANG|LOCAL|OTHER|REGEX|SPOOL|TITLE|TYPES|VALID|WHILE|ALPHA|BOXED|CATCH|CHAIN|CHECK|CLASS|COVER|ENDIF|EQUIV|FIELD|FLOOR|FRAME|INPUT|LOWER|MATCH|NODES|PAGES|PRINT|RAISE|ROUND|SHIFT|SPACE|SPOTS|STAMP|STATE|TASKS|TIMES|TRMAC|ULINE|UNION|VALUE|WIDTH|EQUAL|LOG10|TRUNC|BLOB|CASE|CEIL|CLOB|COND|EXIT|FILE|GAPS|HOLD|INCL|INTO|KEEP|KEYS|LAST|LINE|LONG|LPAD|MAIL|MODE|OPEN|PINK|READ|ROWS|TEST|THEN|ZERO|AREA|BACK|BADI|BYTE|CAST|EDIT|EXEC|FAIL|FIND|FKEQ|FONT|FREE|GKEQ|HIDE|INIT|ITNO|LATE|LOOP|MAIN|MARK|MOVE|NEXT|NULL|RISK|ROLE|UNIT|WAIT|ZONE|BASE|CALL|CODE|DATA|DATE|FKGE|GKGE|HIGH|KIND|LEFT|LIST|MASK|MESH|NAME|NODE|PACK|PAGE|POOL|SEND|SIGN|SIZE|SOME|STOP|TASK|TEXT|TIME|USER|VARY|WITH|WORD|BLUE|CONV|COPY|DEEP|ELSE|FORM|FROM|HINT|ICON|JOIN|LIKE|LOAD|ONLY|PART|SCAN|SKIP|SORT|TYPE|UNIX|VIEW|WHEN|WORK|ACOS|ASIN|ATAN|COSH|EACH|FRAC|LESS|RTTI|SINH|SQRT|TANH|AVG|BIT|DIV|ISO|LET|OUT|PAD|SQL|ALL|CI_|CPI|END|LOB|LPI|MAX|MIN|NEW|OLE|RUN|SET|\?TO|YES|ABS|ADD|AND|BIG|FOR|HDB|JOB|LOW|NOT|SAP|TRY|VIA|XML|ANY|GET|IDS|KEY|MOD|OFF|PUT|RAW|RED|REF|SUM|TAB|XSD|CNT|COS|EXP|LOG|SIN|TAN|XOR|AT|CO|CP|DO|GT|ID|IF|NS|OR|BT|CA|CS|GE|NA|NB|EQ|IN|LT|NE|NO|OF|ON|PF|TO|AS|BY|CN|IS|LE|NP|UP|E|I|M|O|Z|C|X)\b/i,lookbehind:!0},number:/\b\d+\b/,operator:{pattern:/(\s)(?:\*\*?|<[=>]?|>=?|\?=|[-+\/=])(?=\s)/,lookbehind:!0},"string-operator":{pattern:/(\s)&&?(?=\s)/,lookbehind:!0,alias:"keyword"},"token-operator":[{pattern:/(\w)(?:->?|=>|[~|{}])(?=\w)/,lookbehind:!0,alias:"punctuation"},{pattern:/[|{}]/,alias:"punctuation"}],punctuation:/[,.:()]/}}E.exports=N,N.displayName="abap",N.aliases=[]},67191:(E,N,T)=>{T.d(N,{default:()=>O});var I=T(48142);const O=T.n(I)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/67329.08db90c1.chunk.js b/ydb/core/viewer/monitoring/static/js/67329.08db90c1.chunk.js new file mode 100644 index 000000000000..35b71ea12ba1 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/67329.08db90c1.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[67329],{67329:(e,l,t)=>{t.r(l),t.d(l,{ReactComponent:()=>b,default:()=>M});var c,a,h,v,m,n,z,d,i,r,f,s,o,p=t(59284);function E(){return E=Object.assign?Object.assign.bind():function(e){for(var l=1;l{n.r(o),n.d(o,{conf:()=>t,language:()=>s});var t={comments:{lineComment:";",blockComment:["#|","|#"]},brackets:[["(",")"],["{","}"],["[","]"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}]},s={defaultToken:"",ignoreCase:!0,tokenPostfix:".scheme",brackets:[{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"}],keywords:["case","do","let","loop","if","else","when","cons","car","cdr","cond","lambda","lambda*","syntax-rules","format","set!","quote","eval","append","list","list?","member?","load"],constants:["#t","#f"],operators:["eq?","eqv?","equal?","and","or","not","null?"],tokenizer:{root:[[/#[xXoObB][0-9a-fA-F]+/,"number.hex"],[/[+-]?\d+(?:(?:\.\d*)?(?:[eE][+-]?\d+)?)?/,"number.float"],[/(?:\b(?:(define|define-syntax|define-macro))\b)(\s+)((?:\w|\-|\!|\?)*)/,["keyword","white","variable"]],{include:"@whitespace"},{include:"@strings"},[/[a-zA-Z_#][a-zA-Z0-9_\-\?\!\*]*/,{cases:{"@keywords":"keyword","@constants":"constant","@operators":"operators","@default":"identifier"}}]],comment:[[/[^\|#]+/,"comment"],[/#\|/,"comment","@push"],[/\|#/,"comment","@pop"],[/[\|#]/,"comment"]],whitespace:[[/[ \t\r\n]+/,"white"],[/#\|/,"comment","@comment"],[/;.*$/,"comment"]],strings:[[/"$/,"string","@popall"],[/"(?=.)/,"string","@multiLineString"]],multiLineString:[[/[^\\"]+$/,"string","@popall"],[/[^\\"]+/,"string"],[/\\./,"string.escape"],[/"/,"string","@popall"],[/\\$/,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7148.ef54cd41.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/67574.31643beb.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/7148.ef54cd41.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/67574.31643beb.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/67605.6cd42d90.chunk.js b/ydb/core/viewer/monitoring/static/js/67605.6cd42d90.chunk.js new file mode 100644 index 000000000000..4532aea5a061 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/67605.6cd42d90.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[67605],{67605:function(e,_,i){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var i=_(e),n={name:"fr",weekdays:"dimanche_lundi_mardi_mercredi_jeudi_vendredi_samedi".split("_"),weekdaysShort:"dim._lun._mar._mer._jeu._ven._sam.".split("_"),weekdaysMin:"di_lu_ma_me_je_ve_sa".split("_"),months:"janvier_f\xe9vrier_mars_avril_mai_juin_juillet_ao\xfbt_septembre_octobre_novembre_d\xe9cembre".split("_"),monthsShort:"janv._f\xe9vr._mars_avr._mai_juin_juil._ao\xfbt_sept._oct._nov._d\xe9c.".split("_"),weekStart:1,yearStart:4,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"dans %s",past:"il y a %s",s:"quelques secondes",m:"une minute",mm:"%d minutes",h:"une heure",hh:"%d heures",d:"un jour",dd:"%d jours",M:"un mois",MM:"%d mois",y:"un an",yy:"%d ans"},ordinal:function(e){return e+(1===e?"er":"")}};return i.default.locale(n,null,!0),n}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6785.f25ed122.chunk.js b/ydb/core/viewer/monitoring/static/js/6785.f25ed122.chunk.js new file mode 100644 index 000000000000..f79a64fda918 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/6785.f25ed122.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6785],{6785:(e,r,n)=>{n.d(r,{default:()=>o});var t=n(57544);const o=n.n(t)()},57544:e=>{function r(e){!function(e){var r=/\\[\r\n](?:\s|\\[\r\n]|#.*(?!.))*(?![\s#]|\\[\r\n])/.source,n=/(?:[ \t]+(?![ \t])(?:)?|)/.source.replace(//g,(function(){return r})),t=/"(?:[^"\\\r\n]|\\(?:\r\n|[\s\S]))*"|'(?:[^'\\\r\n]|\\(?:\r\n|[\s\S]))*'/.source,o=/--[\w-]+=(?:|(?!["'])(?:[^\s\\]|\\.)+)/.source.replace(//g,(function(){return t})),i={pattern:RegExp(t),greedy:!0},s={pattern:/(^[ \t]*)#.*/m,lookbehind:!0,greedy:!0};function a(e,r){return e=e.replace(//g,(function(){return o})).replace(//g,(function(){return n})),RegExp(e,r)}e.languages.docker={instruction:{pattern:/(^[ \t]*)(?:ADD|ARG|CMD|COPY|ENTRYPOINT|ENV|EXPOSE|FROM|HEALTHCHECK|LABEL|MAINTAINER|ONBUILD|RUN|SHELL|STOPSIGNAL|USER|VOLUME|WORKDIR)(?=\s)(?:\\.|[^\r\n\\])*(?:\\$(?:\s|#.*$)*(?![\s#])(?:\\.|[^\r\n\\])*)*/im,lookbehind:!0,greedy:!0,inside:{options:{pattern:a(/(^(?:ONBUILD)?\w+)(?:)*/.source,"i"),lookbehind:!0,greedy:!0,inside:{property:{pattern:/(^|\s)--[\w-]+/,lookbehind:!0},string:[i,{pattern:/(=)(?!["'])(?:[^\s\\]|\\.)+/,lookbehind:!0}],operator:/\\$/m,punctuation:/=/}},keyword:[{pattern:a(/(^(?:ONBUILD)?HEALTHCHECK(?:)*)(?:CMD|NONE)\b/.source,"i"),lookbehind:!0,greedy:!0},{pattern:a(/(^(?:ONBUILD)?FROM(?:)*(?!--)[^ \t\\]+)AS/.source,"i"),lookbehind:!0,greedy:!0},{pattern:a(/(^ONBUILD)\w+/.source,"i"),lookbehind:!0,greedy:!0},{pattern:/^\w+/,greedy:!0}],comment:s,string:i,variable:/\$(?:\w+|\{[^{}"'\\]*\})/,operator:/\\$/m}},comment:s},e.languages.dockerfile=e.languages.docker}(e)}e.exports=r,r.displayName="docker",r.aliases=["dockerfile"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6786.28af14f6.chunk.js b/ydb/core/viewer/monitoring/static/js/6786.28af14f6.chunk.js deleted file mode 100644 index 02a2c0f49d63..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6786.28af14f6.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6786],{36786:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),u={name:"en-il",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"}};return a.default.locale(u,null,!0),u}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6820.73ff230e.chunk.js b/ydb/core/viewer/monitoring/static/js/6820.73ff230e.chunk.js deleted file mode 100644 index 786b18bca54d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6820.73ff230e.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 6820.73ff230e.chunk.js.LICENSE.txt */ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6820],{71383:(e,t)=>{"use strict";t.q=function(e){var t,a=[],o=String(e||r),l=o.indexOf(n),c=0,i=!1;for(;!i;)-1===l&&(l=o.length,i=!0),!(t=o.slice(c,l).trim())&&i||a.push(t),c=l+1,l=o.indexOf(n,c);return a};var n=",",a=" ",r=""},91448:e=>{"use strict";e.exports=function(e,n){var a,r,o,l=e||"",c=n||"div",i={},s=0;for(;s{"use strict";var a=n(47556),r=n(72996),o=n(91448),l=n(82140).q,c=n(71383).q;e.exports=function(e,t,n){var r=n?function(e){var t,n=e.length,a=-1,r={};for(;++a{"use strict";var a=n(70730),r=n(27376)(a,"div");r.displayName="html",e.exports=r},55942:(e,t,n)=>{"use strict";e.exports=n(48893)},73934:e=>{"use strict";e.exports=function(e){var t="string"===typeof e?e.charCodeAt(0):e;return t>=97&&t<=122||t>=65&&t<=90}},494:(e,t,n)=>{"use strict";var a=n(73934),r=n(94667);e.exports=function(e){return a(e)||r(e)}},94667:e=>{"use strict";e.exports=function(e){var t="string"===typeof e?e.charCodeAt(0):e;return t>=48&&t<=57}},83991:e=>{"use strict";e.exports=function(e){var t="string"===typeof e?e.charCodeAt(0):e;return t>=97&&t<=102||t>=65&&t<=70||t>=48&&t<=57}},43733:(e,t,n)=>{"use strict";n.d(t,{RE:()=>a,XB:()=>o,to:()=>r});const a="$row|$rows|action|add|all|alter|and|any|as|asc|assume|async|bigserial|serial|smallserial|serial8|serial4|serial2|begin|bernoulli|between|by|case|changefeed|column|columns|commit|compact|create|cross|cube|declare|define|delete|desc|dict|discard|distinct|do|drop|else|empty_action|end|erase|evaluate|exclusion|exists|export|family|flatten|for|from|full|global|group|grouping|having|if|ignore|ilike|import|in|index|inner|insert|into|is|join|key|left|like|limit|list|match|not|null|nulls|offset|on|only|optional|or|order|over|partition|pragma|presort|primary|process|reduce|regexp|repeatable|replace|respect|result|return|right|rlike|rollup|sample|schema|select|semi|set|sets|stream|subquery|sync|table|tablesample|then|truncate|union|intersect|except|update|upsert|use|using|values|view|when|where|window|with|without|xor|callable|resource|tagged|generic|unit|void|emptylist|emptydict|flow|callable|resource|tagged|generic|unit|void|emptylist|emptydict|flow".split("|"),r="bool|date|datetime|decimal|double|float|int16|int32|int64|int8|interval|json|jsondocument|string|timestamp|tzdate|tzdatetime|tztimestamp|uint16|uint32|uint64|uint8|utf8|uuid|yson|text|bytes".split("|"),o="abs|aggregate_by|aggregate_list|aggregate_list_distinct|agg_list|agg_list_distinct|as_table|avg|avg_if|adaptivedistancehistogram|adaptivewardhistogram|adaptiveweighthistogram|addmember|addtimezone|aggregateflatten|aggregatetransforminput|aggregatetransformoutput|aggregationfactory|asatom|asdict|asdictstrict|asenum|aslist|asliststrict|asset|assetstrict|asstruct|astagged|astuple|asvariant|atomcode|bitcast|bit_and|bit_or|bit_xor|bool_and|bool_or|bool_xor|bottom|bottom_by|blockwardhistogram|blockweighthistogram|cast|coalesce|concat|concat_strict|correlation|count|count_if|covariance|covariance_population|covariance_sample|callableargument|callableargumenttype|callableresulttype|callabletype|callabletypecomponents|callabletypehandle|choosemembers|combinemembers|countdistinctestimate|currentauthenticateduser|currentoperationid|currentoperationsharedid|currenttzdate|currenttzdatetime|currenttztimestamp|currentutcdate|currentutcdatetime|currentutctimestamp|dense_rank|datatype|datatypecomponents|datatypehandle|dictaggregate|dictcontains|dictcreate|dicthasitems|dictitems|dictkeytype|dictkeys|dictlength|dictlookup|dictpayloadtype|dictpayloads|dicttype|dicttypecomponents|dicttypehandle|each|each_strict|emptydicttype|emptydicttypehandle|emptylisttype|emptylisttypehandle|endswith|ensure|ensureconvertibleto|ensuretype|enum|evaluateatom|evaluatecode|evaluateexpr|evaluatetype|expandstruct|filter|filter_strict|find|first_value|folder|filecontent|filepath|flattenmembers|forceremovemember|forceremovemembers|forcerenamemembers|forcespreadmembers|formatcode|formattype|frombytes|frompg|funccode|greatest|grouping|gathermembers|generictype|histogram|hll|hoppingwindowpgcast|hyperloglog|if|if_strict|instanceof|json_exists|json_query|json_value|jointablerow|just|lag|last_value|lead|least|len|length|like|likely|like_strict|lambdaargumentscount|lambdacode|lambdaoptionalargumentscount|linearhistogram|listaggregate|listall|listany|listavg|listcode|listcollect|listconcat|listcreate|listdistinct|listenumerate|listextend|listextendstrict|listextract|listfilter|listflatmap|listflatten|listfold|listfold1|listfold1map|listfoldmap|listfromrange|listfromtuple|listhas|listhasitems|listhead|listindexof|listitemtype|listlast|listlength|listmap|listmax|listmin|listnotnull|listreplicate|listreverse|listskip|listskipwhile|listskipwhileinclusive|listsort|listsortasc|listsortdesc|listsum|listtake|listtakewhile|listtakewhileinclusive|listtop|listtopsort|listtopasc|listtopdesc|listtopsortasc|listtopsortdesc|listtotuple|listtype|listtypehandle|listunionall|listuniq|listzip|listzipall|loghistogram|logarithmichistogram|max|max_by|max_of|median|min|min_by|min_of|mode|multi_aggregate_by|nanvl|nvl|nothing|nulltype|nulltypehandle|optionalitemtype|optionaltype|optionaltypehandle|percentile|parsefile|parsetype|parsetypehandle|pgand|pgarray|pgcall|pgconst|pgnot|pgop|pgor|pickle|quotecode|range|range_strict|rank|regexp|regexp_strict|rfind|row_number|random|randomnumber|randomuuid|removemember|removemembers|removetimezone|renamemembers|replacemember|reprcode|resourcetype|resourcetypehandle|resourcetypetag|some|stddev|stddev_population|stddev_sample|substring|sum|sum_if|sessionstart|sessionwindow|setcreate|setdifference|setincludes|setintersection|setisdisjoint|setsymmetricdifference|setunion|spreadmembers|stablepickle|startswith|staticmap|staticzip|streamitemtype|streamtype|streamtypehandle|structmembertype|structmembers|structtypecomponents|structtypehandle|subqueryextend|subqueryextendfor|subquerymerge|subquerymergefor|subqueryunionall|subqueryunionallfor|subqueryunionmerge|subqueryunionmergefor|top|topfreq|top_by|tablename|tablepath|tablerecordindex|tablerow|tablerows|taggedtype|taggedtypecomponents|taggedtypehandle|tobytes|todict|tomultidict|topg|toset|tosorteddict|tosortedmultidict|trymember|tupleelementtype|tupletype|tupletypecomponents|tupletypehandle|typehandle|typekind|typeof|udaf|udf|unittype|unpickle|untag|unwrap|variance|variance_population|variance_sample|variant|varianttype|varianttypehandle|variantunderlyingtype|voidtype|voidtypehandle|way|worldcode|weakfield".split("|")},64016:e=>{"use strict";var t;e.exports=function(e){var n,a="&"+e+";";if((t=t||document.createElement("i")).innerHTML=a,59===(n=t.textContent).charCodeAt(n.length-1)&&"semi"!==e)return!1;return n!==a&&n}},72824:(e,t,n)=>{"use strict";var a=n(82719),r=n(21257),o=n(94667),l=n(83991),c=n(494),i=n(64016);e.exports=function(e,t){var n,o,l={};t||(t={});for(o in p)n=t[o],l[o]=null===n||void 0===n?p[o]:n;(l.position.indent||l.position.start)&&(l.indent=l.position.indent||[],l.position=l.position.start);return function(e,t){var n,o,l,p,R,q,H,B,U,W,V,Z,G,K,J,Y,X,Q,ee,te=t.additional,ne=t.nonTerminated,ae=t.text,re=t.reference,oe=t.warning,le=t.textContext,ce=t.referenceContext,ie=t.warningContext,se=t.position,ue=t.indent||[],de=e.length,pe=0,ge=-1,me=se.column||1,fe=se.line||1,he="",ye=[];"string"===typeof te&&(te=te.charCodeAt(0));Y=be(),B=oe?ve:d,pe--,de++;for(;++pe65535&&(W+=u((q-=65536)>>>10|55296),q=56320|1023&q),q=W+u(q))):K!==F&&B(E,Q)),q?(we(),Y=be(),pe=ee-1,me+=ee-G+1,ye.push(q),(X=be()).offset++,re&&re.call(ce,q,{start:Y,end:X},e.slice(G-1,ee)),Y=X):(p=e.slice(G-1,ee),he+=p,me+=p.length,pe=ee-1)}else 10===R&&(fe++,ge++,me=0),R===R?(he+=u(R),me++):we();return ye.join("");function be(){return{line:fe,column:me,offset:pe+(se.offset||0)}}function ve(e,t){var n=be();n.column+=t,n.offset+=t,oe.call(ie,$[e],n,e)}function we(){he&&(ye.push(he),ae&&ae.call(le,he,{start:Y,end:be()}),he="")}}(e,l)};var s={}.hasOwnProperty,u=String.fromCharCode,d=Function.prototype,p={warning:null,reference:null,text:null,warningContext:null,referenceContext:null,textContext:null,position:{},additional:null,attribute:!1,nonTerminated:!0},g=9,m=10,f=12,h=32,y=38,b=59,v=60,w=61,x=35,k=88,S=120,A=65533,F="named",O="hexadecimal",N="decimal",C={};C[O]=16,C[N]=10;var j={};j[F]=c,j[N]=o,j[O]=l;var P=1,L=2,_=3,E=4,z=5,M=6,T=7,$={};function D(e){return e>=55296&&e<=57343||e>1114111}function I(e){return e>=1&&e<=8||11===e||e>=13&&e<=31||e>=127&&e<=159||e>=64976&&e<=65007||65535===(65535&e)||65534===(65535&e)}$[P]="Named character references must be terminated by a semicolon",$[L]="Numeric character references must be terminated by a semicolon",$[_]="Named character references cannot be empty",$[E]="Numeric character references cannot be empty",$[z]="Named character references must be known",$[M]="Numeric character references cannot be disallowed",$[T]="Numeric character references cannot be outside the permissible Unicode range"},47556:(e,t,n)=>{"use strict";var a=n(72996),r=n(70302),o=n(58974),l="data";e.exports=function(e,t){var n=a(t),p=t,g=o;if(n in e.normal)return e.property[e.normal[n]];n.length>4&&n.slice(0,4)===l&&c.test(t)&&("-"===t.charAt(4)?p=function(e){var t=e.slice(5).replace(i,d);return l+t.charAt(0).toUpperCase()+t.slice(1)}(t):t=function(e){var t=e.slice(4);if(i.test(t))return e;t=t.replace(s,u),"-"!==t.charAt(0)&&(t="-"+t);return l+t}(t),g=r);return new g(p,t)};var c=/^data[-\w.:]+$/i,i=/-[a-z]/g,s=/[A-Z]/g;function u(e){return"-"+e.toLowerCase()}function d(e){return e.charAt(1).toUpperCase()}},70730:(e,t,n)=>{"use strict";var a=n(35228),r=n(83851),o=n(91622),l=n(61945),c=n(11666),i=n(59162);e.exports=a([o,r,l,c,i])},11666:(e,t,n)=>{"use strict";var a=n(73125),r=n(71478),o=a.booleanish,l=a.number,c=a.spaceSeparated;e.exports=r({transform:function(e,t){return"role"===t?t:"aria-"+t.slice(4).toLowerCase()},properties:{ariaActiveDescendant:null,ariaAtomic:o,ariaAutoComplete:null,ariaBusy:o,ariaChecked:o,ariaColCount:l,ariaColIndex:l,ariaColSpan:l,ariaControls:c,ariaCurrent:null,ariaDescribedBy:c,ariaDetails:null,ariaDisabled:o,ariaDropEffect:c,ariaErrorMessage:null,ariaExpanded:o,ariaFlowTo:c,ariaGrabbed:o,ariaHasPopup:null,ariaHidden:o,ariaInvalid:null,ariaKeyShortcuts:null,ariaLabel:null,ariaLabelledBy:c,ariaLevel:l,ariaLive:null,ariaModal:o,ariaMultiLine:o,ariaMultiSelectable:o,ariaOrientation:null,ariaOwns:c,ariaPlaceholder:null,ariaPosInSet:l,ariaPressed:o,ariaReadOnly:o,ariaRelevant:null,ariaRequired:o,ariaRoleDescription:c,ariaRowCount:l,ariaRowIndex:l,ariaRowSpan:l,ariaSelected:o,ariaSetSize:l,ariaSort:null,ariaValueMax:l,ariaValueMin:l,ariaValueNow:l,ariaValueText:null,role:null}})},59162:(e,t,n)=>{"use strict";var a=n(73125),r=n(71478),o=n(70503),l=a.boolean,c=a.overloadedBoolean,i=a.booleanish,s=a.number,u=a.spaceSeparated,d=a.commaSeparated;e.exports=r({space:"html",attributes:{acceptcharset:"accept-charset",classname:"class",htmlfor:"for",httpequiv:"http-equiv"},transform:o,mustUseProperty:["checked","multiple","muted","selected"],properties:{abbr:null,accept:d,acceptCharset:u,accessKey:u,action:null,allow:null,allowFullScreen:l,allowPaymentRequest:l,allowUserMedia:l,alt:null,as:null,async:l,autoCapitalize:null,autoComplete:u,autoFocus:l,autoPlay:l,capture:l,charSet:null,checked:l,cite:null,className:u,cols:s,colSpan:null,content:null,contentEditable:i,controls:l,controlsList:u,coords:s|d,crossOrigin:null,data:null,dateTime:null,decoding:null,default:l,defer:l,dir:null,dirName:null,disabled:l,download:c,draggable:i,encType:null,enterKeyHint:null,form:null,formAction:null,formEncType:null,formMethod:null,formNoValidate:l,formTarget:null,headers:u,height:s,hidden:l,high:s,href:null,hrefLang:null,htmlFor:u,httpEquiv:u,id:null,imageSizes:null,imageSrcSet:d,inputMode:null,integrity:null,is:null,isMap:l,itemId:null,itemProp:u,itemRef:u,itemScope:l,itemType:u,kind:null,label:null,lang:null,language:null,list:null,loading:null,loop:l,low:s,manifest:null,max:null,maxLength:s,media:null,method:null,min:null,minLength:s,multiple:l,muted:l,name:null,nonce:null,noModule:l,noValidate:l,onAbort:null,onAfterPrint:null,onAuxClick:null,onBeforePrint:null,onBeforeUnload:null,onBlur:null,onCancel:null,onCanPlay:null,onCanPlayThrough:null,onChange:null,onClick:null,onClose:null,onContextMenu:null,onCopy:null,onCueChange:null,onCut:null,onDblClick:null,onDrag:null,onDragEnd:null,onDragEnter:null,onDragExit:null,onDragLeave:null,onDragOver:null,onDragStart:null,onDrop:null,onDurationChange:null,onEmptied:null,onEnded:null,onError:null,onFocus:null,onFormData:null,onHashChange:null,onInput:null,onInvalid:null,onKeyDown:null,onKeyPress:null,onKeyUp:null,onLanguageChange:null,onLoad:null,onLoadedData:null,onLoadedMetadata:null,onLoadEnd:null,onLoadStart:null,onMessage:null,onMessageError:null,onMouseDown:null,onMouseEnter:null,onMouseLeave:null,onMouseMove:null,onMouseOut:null,onMouseOver:null,onMouseUp:null,onOffline:null,onOnline:null,onPageHide:null,onPageShow:null,onPaste:null,onPause:null,onPlay:null,onPlaying:null,onPopState:null,onProgress:null,onRateChange:null,onRejectionHandled:null,onReset:null,onResize:null,onScroll:null,onSecurityPolicyViolation:null,onSeeked:null,onSeeking:null,onSelect:null,onSlotChange:null,onStalled:null,onStorage:null,onSubmit:null,onSuspend:null,onTimeUpdate:null,onToggle:null,onUnhandledRejection:null,onUnload:null,onVolumeChange:null,onWaiting:null,onWheel:null,open:l,optimum:s,pattern:null,ping:u,placeholder:null,playsInline:l,poster:null,preload:null,readOnly:l,referrerPolicy:null,rel:u,required:l,reversed:l,rows:s,rowSpan:s,sandbox:u,scope:null,scoped:l,seamless:l,selected:l,shape:null,size:s,sizes:null,slot:null,span:s,spellCheck:i,src:null,srcDoc:null,srcLang:null,srcSet:d,start:s,step:null,style:null,tabIndex:s,target:null,title:null,translate:null,type:null,typeMustMatch:l,useMap:null,value:i,width:s,wrap:null,align:null,aLink:null,archive:u,axis:null,background:null,bgColor:null,border:s,borderColor:null,bottomMargin:s,cellPadding:null,cellSpacing:null,char:null,charOff:null,classId:null,clear:null,code:null,codeBase:null,codeType:null,color:null,compact:l,declare:l,event:null,face:null,frame:null,frameBorder:null,hSpace:s,leftMargin:s,link:null,longDesc:null,lowSrc:null,marginHeight:s,marginWidth:s,noResize:l,noHref:l,noShade:l,noWrap:l,object:null,profile:null,prompt:null,rev:null,rightMargin:s,rules:null,scheme:null,scrolling:i,standby:null,summary:null,text:null,topMargin:s,valueType:null,version:null,vAlign:null,vLink:null,vSpace:s,allowTransparency:null,autoCorrect:null,autoSave:null,disablePictureInPicture:l,disableRemotePlayback:l,prefix:null,property:null,results:s,security:null,unselectable:null}})},70503:(e,t,n)=>{"use strict";var a=n(32990);e.exports=function(e,t){return a(e,t.toLowerCase())}},32990:e=>{"use strict";e.exports=function(e,t){return t in e?e[t]:t}},71478:(e,t,n)=>{"use strict";var a=n(72996),r=n(9009),o=n(70302);e.exports=function(e){var t,n,l=e.space,c=e.mustUseProperty||[],i=e.attributes||{},s=e.properties,u=e.transform,d={},p={};for(t in s)n=new o(t,u(i,t),s[t],l),-1!==c.indexOf(t)&&(n.mustUseProperty=!0),d[t]=n,p[a(t)]=t,p[a(n.attribute)]=t;return new r(d,p,l)}},70302:(e,t,n)=>{"use strict";var a=n(58974),r=n(73125);e.exports=c,c.prototype=new a,c.prototype.defined=!0;var o=["boolean","booleanish","overloadedBoolean","number","commaSeparated","spaceSeparated","commaOrSpaceSeparated"],l=o.length;function c(e,t,n,c){var s,u=-1;for(i(this,"space",c),a.call(this,e,t);++u{"use strict";e.exports=n;var t=n.prototype;function n(e,t){this.property=e,this.attribute=t}t.space=null,t.attribute=null,t.property=null,t.boolean=!1,t.booleanish=!1,t.overloadedBoolean=!1,t.number=!1,t.commaSeparated=!1,t.spaceSeparated=!1,t.commaOrSpaceSeparated=!1,t.mustUseProperty=!1,t.defined=!1},35228:(e,t,n)=>{"use strict";var a=n(31630),r=n(9009);e.exports=function(e){var t,n,o=e.length,l=[],c=[],i=-1;for(;++i{"use strict";e.exports=n;var t=n.prototype;function n(e,t,n){this.property=e,this.normal=t,n&&(this.space=n)}t.space=null,t.normal={},t.property={}},73125:(e,t)=>{"use strict";var n=0;function a(){return Math.pow(2,++n)}t.boolean=a(),t.booleanish=a(),t.overloadedBoolean=a(),t.number=a(),t.spaceSeparated=a(),t.commaSeparated=a(),t.commaOrSpaceSeparated=a()},83851:(e,t,n)=>{"use strict";var a=n(71478);e.exports=a({space:"xlink",transform:function(e,t){return"xlink:"+t.slice(5).toLowerCase()},properties:{xLinkActuate:null,xLinkArcRole:null,xLinkHref:null,xLinkRole:null,xLinkShow:null,xLinkTitle:null,xLinkType:null}})},91622:(e,t,n)=>{"use strict";var a=n(71478);e.exports=a({space:"xml",transform:function(e,t){return"xml:"+t.slice(3).toLowerCase()},properties:{xmlLang:null,xmlBase:null,xmlSpace:null}})},61945:(e,t,n)=>{"use strict";var a=n(71478),r=n(70503);e.exports=a({space:"xmlns",attributes:{xmlnsxlink:"xmlns:xlink"},transform:r,properties:{xmlns:null,xmlnsXLink:null}})},72996:e=>{"use strict";e.exports=function(e){return e.toLowerCase()}},96298:(e,t,n)=>{"use strict";n.d(t,{A:()=>z});var a=n(98587);function r(e,t){(null==t||t>e.length)&&(t=e.length);for(var n=0,a=Array(t);n1&&void 0!==arguments[1]?arguments[1]:{},n=arguments.length>2?arguments[2]:void 0;return function(e){if(0===e.length||1===e.length)return e;var t=e.join(".");return g[t]||(g[t]=function(e){var t=e.length;return 0===t||1===t?e:2===t?[e[0],e[1],"".concat(e[0],".").concat(e[1]),"".concat(e[1],".").concat(e[0])]:3===t?[e[0],e[1],e[2],"".concat(e[0],".").concat(e[1]),"".concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[0]),"".concat(e[1],".").concat(e[2]),"".concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[1]),"".concat(e[0],".").concat(e[1],".").concat(e[2]),"".concat(e[0],".").concat(e[2],".").concat(e[1]),"".concat(e[1],".").concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[0],".").concat(e[1]),"".concat(e[2],".").concat(e[1],".").concat(e[0])]:t>=4?[e[0],e[1],e[2],e[3],"".concat(e[0],".").concat(e[1]),"".concat(e[0],".").concat(e[2]),"".concat(e[0],".").concat(e[3]),"".concat(e[1],".").concat(e[0]),"".concat(e[1],".").concat(e[2]),"".concat(e[1],".").concat(e[3]),"".concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[1]),"".concat(e[2],".").concat(e[3]),"".concat(e[3],".").concat(e[0]),"".concat(e[3],".").concat(e[1]),"".concat(e[3],".").concat(e[2]),"".concat(e[0],".").concat(e[1],".").concat(e[2]),"".concat(e[0],".").concat(e[1],".").concat(e[3]),"".concat(e[0],".").concat(e[2],".").concat(e[1]),"".concat(e[0],".").concat(e[2],".").concat(e[3]),"".concat(e[0],".").concat(e[3],".").concat(e[1]),"".concat(e[0],".").concat(e[3],".").concat(e[2]),"".concat(e[1],".").concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[0],".").concat(e[3]),"".concat(e[1],".").concat(e[2],".").concat(e[0]),"".concat(e[1],".").concat(e[2],".").concat(e[3]),"".concat(e[1],".").concat(e[3],".").concat(e[0]),"".concat(e[1],".").concat(e[3],".").concat(e[2]),"".concat(e[2],".").concat(e[0],".").concat(e[1]),"".concat(e[2],".").concat(e[0],".").concat(e[3]),"".concat(e[2],".").concat(e[1],".").concat(e[0]),"".concat(e[2],".").concat(e[1],".").concat(e[3]),"".concat(e[2],".").concat(e[3],".").concat(e[0]),"".concat(e[2],".").concat(e[3],".").concat(e[1]),"".concat(e[3],".").concat(e[0],".").concat(e[1]),"".concat(e[3],".").concat(e[0],".").concat(e[2]),"".concat(e[3],".").concat(e[1],".").concat(e[0]),"".concat(e[3],".").concat(e[1],".").concat(e[2]),"".concat(e[3],".").concat(e[2],".").concat(e[0]),"".concat(e[3],".").concat(e[2],".").concat(e[1]),"".concat(e[0],".").concat(e[1],".").concat(e[2],".").concat(e[3]),"".concat(e[0],".").concat(e[1],".").concat(e[3],".").concat(e[2]),"".concat(e[0],".").concat(e[2],".").concat(e[1],".").concat(e[3]),"".concat(e[0],".").concat(e[2],".").concat(e[3],".").concat(e[1]),"".concat(e[0],".").concat(e[3],".").concat(e[1],".").concat(e[2]),"".concat(e[0],".").concat(e[3],".").concat(e[2],".").concat(e[1]),"".concat(e[1],".").concat(e[0],".").concat(e[2],".").concat(e[3]),"".concat(e[1],".").concat(e[0],".").concat(e[3],".").concat(e[2]),"".concat(e[1],".").concat(e[2],".").concat(e[0],".").concat(e[3]),"".concat(e[1],".").concat(e[2],".").concat(e[3],".").concat(e[0]),"".concat(e[1],".").concat(e[3],".").concat(e[0],".").concat(e[2]),"".concat(e[1],".").concat(e[3],".").concat(e[2],".").concat(e[0]),"".concat(e[2],".").concat(e[0],".").concat(e[1],".").concat(e[3]),"".concat(e[2],".").concat(e[0],".").concat(e[3],".").concat(e[1]),"".concat(e[2],".").concat(e[1],".").concat(e[0],".").concat(e[3]),"".concat(e[2],".").concat(e[1],".").concat(e[3],".").concat(e[0]),"".concat(e[2],".").concat(e[3],".").concat(e[0],".").concat(e[1]),"".concat(e[2],".").concat(e[3],".").concat(e[1],".").concat(e[0]),"".concat(e[3],".").concat(e[0],".").concat(e[1],".").concat(e[2]),"".concat(e[3],".").concat(e[0],".").concat(e[2],".").concat(e[1]),"".concat(e[3],".").concat(e[1],".").concat(e[0],".").concat(e[2]),"".concat(e[3],".").concat(e[1],".").concat(e[2],".").concat(e[0]),"".concat(e[3],".").concat(e[2],".").concat(e[0],".").concat(e[1]),"".concat(e[3],".").concat(e[2],".").concat(e[1],".").concat(e[0])]:void 0}(e)),g[t]}(e.filter((function(e){return"token"!==e}))).reduce((function(e,t){return p(p({},e),n[t])}),t)}function f(e){return e.join(" ")}function h(e){var t=e.node,n=e.stylesheet,a=e.style,r=void 0===a?{}:a,o=e.useInlineStyles,l=e.key,c=t.properties,i=t.type,d=t.tagName,g=t.value;if("text"===i)return g;if(d){var y,b=function(e,t){var n=0;return function(a){return n+=1,a.map((function(a,r){return h({node:a,stylesheet:e,useInlineStyles:t,key:"code-segment-".concat(n,"-").concat(r)})}))}}(n,o);if(o){var v=Object.keys(n).reduce((function(e,t){return t.split(".").forEach((function(t){e.includes(t)||e.push(t)})),e}),[]),w=c.className&&c.className.includes("token")?["token"]:[],x=c.className&&w.concat(c.className.filter((function(e){return!v.includes(e)})));y=p(p({},c),{},{className:f(x)||void 0,style:m(c.className,Object.assign({},c.style,r),n)})}else y=p(p({},c),{},{className:f(c.className)});var k=b(t.children);return s.createElement(d,(0,u.A)({key:l},y),k)}}var y=["language","children","style","customStyle","codeTagProps","useInlineStyles","showLineNumbers","showInlineLineNumbers","startingLineNumber","lineNumberContainerStyle","lineNumberStyle","wrapLines","wrapLongLines","lineProps","renderer","PreTag","CodeTag","code","astGenerator"];function b(e,t){var n=Object.keys(e);if(Object.getOwnPropertySymbols){var a=Object.getOwnPropertySymbols(e);t&&(a=a.filter((function(t){return Object.getOwnPropertyDescriptor(e,t).enumerable}))),n.push.apply(n,a)}return n}function v(e){for(var t=1;t1&&void 0!==arguments[1]?arguments[1]:[],n=arguments.length>2&&void 0!==arguments[2]?arguments[2]:[],a=0;a2&&void 0!==arguments[2]?arguments[2]:[];return t||s.length>0?function(e,o){return A({children:e,lineNumber:o,lineNumberStyle:c,largestLineNumber:l,showInlineLineNumbers:r,lineProps:n,className:arguments.length>2&&void 0!==arguments[2]?arguments[2]:[],showLineNumbers:a,wrapLongLines:i,wrapLines:t})}(e,o,s):function(e,t){if(a&&t&&r){var n=S(c,t,l);e.unshift(k(t,n))}return e}(e,o)}for(var f=function(){var e=u[g],t=e.children[0].value;if(t.match(w)){var n=t.split("\n");n.forEach((function(t,r){var l=a&&d.length+o,c={type:"text",value:"".concat(t,"\n")};if(0===r){var i=m(u.slice(p+1,g).concat(A({children:[c],className:e.properties.className})),l);d.push(i)}else if(r===n.length-1){var s=u[g+1]&&u[g+1].children&&u[g+1].children[0],f={type:"text",value:"".concat(t)};if(s){var h=A({children:[f],className:e.properties.className});u.splice(g+1,0,h)}else{var y=m([f],l,e.properties.className);d.push(y)}}else{var b=m([c],l,e.properties.className);d.push(b)}})),p=g}g++};g{"use strict";n.d(t,{A:()=>a});const a={'code[class*="language-"]':{textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",wordWrap:"normal",color:"#90a4ae",background:"#fafafa",fontFamily:"Roboto Mono, monospace",fontSize:"1em",lineHeight:"1.5em",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none"},'pre[class*="language-"]':{textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",wordWrap:"normal",color:"#90a4ae",background:"#fafafa",fontFamily:"Roboto Mono, monospace",fontSize:"1em",lineHeight:"1.5em",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none",overflow:"auto",position:"relative",margin:"0.5em 0",padding:"1.25em 1em"},'code[class*="language-"]::-moz-selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"]::-moz-selection':{background:"#cceae7",color:"#263238"},'code[class*="language-"] ::-moz-selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"] ::-moz-selection':{background:"#cceae7",color:"#263238"},'code[class*="language-"]::selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"]::selection':{background:"#cceae7",color:"#263238"},'code[class*="language-"] ::selection':{background:"#cceae7",color:"#263238"},'pre[class*="language-"] ::selection':{background:"#cceae7",color:"#263238"},':not(pre) > code[class*="language-"]':{whiteSpace:"normal",borderRadius:"0.2em",padding:"0.1em"},".language-css > code":{color:"#f76d47"},".language-sass > code":{color:"#f76d47"},".language-scss > code":{color:"#f76d47"},'[class*="language-"] .namespace':{Opacity:"0.7"},atrule:{color:"#7c4dff"},"attr-name":{color:"#39adb5"},"attr-value":{color:"#f6a434"},attribute:{color:"#f6a434"},boolean:{color:"#7c4dff"},builtin:{color:"#39adb5"},cdata:{color:"#39adb5"},char:{color:"#39adb5"},class:{color:"#39adb5"},"class-name":{color:"#6182b8"},comment:{color:"#aabfc9"},constant:{color:"#7c4dff"},deleted:{color:"#e53935"},doctype:{color:"#aabfc9"},entity:{color:"#e53935"},function:{color:"#7c4dff"},hexcode:{color:"#f76d47"},id:{color:"#7c4dff",fontWeight:"bold"},important:{color:"#7c4dff",fontWeight:"bold"},inserted:{color:"#39adb5"},keyword:{color:"#7c4dff"},number:{color:"#f76d47"},operator:{color:"#39adb5"},prolog:{color:"#aabfc9"},property:{color:"#39adb5"},"pseudo-class":{color:"#f6a434"},"pseudo-element":{color:"#f6a434"},punctuation:{color:"#39adb5"},regex:{color:"#6182b8"},selector:{color:"#e53935"},string:{color:"#f6a434"},symbol:{color:"#7c4dff"},tag:{color:"#e53935"},unit:{color:"#f76d47"},url:{color:"#e53935"},variable:{color:"#e53935"}}},62422:(e,t,n)=>{"use strict";n.d(t,{A:()=>a});const a={'pre[class*="language-"]':{color:"#d4d4d4",fontSize:"13px",textShadow:"none",fontFamily:'Menlo, Monaco, Consolas, "Andale Mono", "Ubuntu Mono", "Courier New", monospace',direction:"ltr",textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",lineHeight:"1.5",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none",padding:"1em",margin:".5em 0",overflow:"auto",background:"#1e1e1e"},'code[class*="language-"]':{color:"#d4d4d4",fontSize:"13px",textShadow:"none",fontFamily:'Menlo, Monaco, Consolas, "Andale Mono", "Ubuntu Mono", "Courier New", monospace',direction:"ltr",textAlign:"left",whiteSpace:"pre",wordSpacing:"normal",wordBreak:"normal",lineHeight:"1.5",MozTabSize:"4",OTabSize:"4",tabSize:"4",WebkitHyphens:"none",MozHyphens:"none",msHyphens:"none",hyphens:"none"},'pre[class*="language-"]::selection':{textShadow:"none",background:"#264F78"},'code[class*="language-"]::selection':{textShadow:"none",background:"#264F78"},'pre[class*="language-"] *::selection':{textShadow:"none",background:"#264F78"},'code[class*="language-"] *::selection':{textShadow:"none",background:"#264F78"},':not(pre) > code[class*="language-"]':{padding:".1em .3em",borderRadius:".3em",color:"#db4c69",background:"#1e1e1e"},".namespace":{Opacity:".7"},"doctype.doctype-tag":{color:"#569CD6"},"doctype.name":{color:"#9cdcfe"},comment:{color:"#6a9955"},prolog:{color:"#6a9955"},punctuation:{color:"#d4d4d4"},".language-html .language-css .token.punctuation":{color:"#d4d4d4"},".language-html .language-javascript .token.punctuation":{color:"#d4d4d4"},property:{color:"#9cdcfe"},tag:{color:"#569cd6"},boolean:{color:"#569cd6"},number:{color:"#b5cea8"},constant:{color:"#9cdcfe"},symbol:{color:"#b5cea8"},inserted:{color:"#b5cea8"},unit:{color:"#b5cea8"},selector:{color:"#d7ba7d"},"attr-name":{color:"#9cdcfe"},string:{color:"#ce9178"},char:{color:"#ce9178"},builtin:{color:"#ce9178"},deleted:{color:"#ce9178"},".language-css .token.string.url":{textDecoration:"underline"},operator:{color:"#d4d4d4"},entity:{color:"#569cd6"},"operator.arrow":{color:"#569CD6"},atrule:{color:"#ce9178"},"atrule.rule":{color:"#c586c0"},"atrule.url":{color:"#9cdcfe"},"atrule.url.function":{color:"#dcdcaa"},"atrule.url.punctuation":{color:"#d4d4d4"},keyword:{color:"#569CD6"},"keyword.module":{color:"#c586c0"},"keyword.control-flow":{color:"#c586c0"},function:{color:"#dcdcaa"},"function.maybe-class-name":{color:"#dcdcaa"},regex:{color:"#d16969"},important:{color:"#569cd6"},italic:{fontStyle:"italic"},"class-name":{color:"#4ec9b0"},"maybe-class-name":{color:"#4ec9b0"},console:{color:"#9cdcfe"},parameter:{color:"#9cdcfe"},interpolation:{color:"#9cdcfe"},"punctuation.interpolation-punctuation":{color:"#569cd6"},variable:{color:"#9cdcfe"},"imports.maybe-class-name":{color:"#9cdcfe"},"exports.maybe-class-name":{color:"#9cdcfe"},escape:{color:"#d7ba7d"},"tag.punctuation":{color:"#808080"},cdata:{color:"#808080"},"attr-value":{color:"#ce9178"},"attr-value.punctuation":{color:"#ce9178"},"attr-value.punctuation.attr-equals":{color:"#d4d4d4"},namespace:{color:"#4ec9b0"},'pre[class*="language-javascript"]':{color:"#9cdcfe"},'code[class*="language-javascript"]':{color:"#9cdcfe"},'pre[class*="language-jsx"]':{color:"#9cdcfe"},'code[class*="language-jsx"]':{color:"#9cdcfe"},'pre[class*="language-typescript"]':{color:"#9cdcfe"},'code[class*="language-typescript"]':{color:"#9cdcfe"},'pre[class*="language-tsx"]':{color:"#9cdcfe"},'code[class*="language-tsx"]':{color:"#9cdcfe"},'pre[class*="language-css"]':{color:"#ce9178"},'code[class*="language-css"]':{color:"#ce9178"},'pre[class*="language-html"]':{color:"#d4d4d4"},'code[class*="language-html"]':{color:"#d4d4d4"},".language-regex .token.anchor":{color:"#dcdcaa"},".language-html .token.punctuation":{color:"#808080"},'pre[class*="language-"] > code[class*="language-"]':{position:"relative",zIndex:"1"},".line-highlight.line-highlight":{background:"#f7ebc6",boxShadow:"inset 5px 0 0 #f7d87c",zIndex:"0"}}},86598:(e,t,n)=>{"use strict";var a="object"===typeof globalThis?globalThis:"object"===typeof self?self:"object"===typeof window?window:"object"===typeof n.g?n.g:{},r=function(){var e="Prism"in a,t=e?a.Prism:void 0;return function(){e?a.Prism=t:delete a.Prism;e=void 0,t=void 0}}();a.Prism={manual:!0,disableWorkerMessageHandler:!0};var o=n(55942),l=n(72824),c=n(93915),i=n(33592),s=n(61993),u=n(22216),d=n(50683);r();var p={}.hasOwnProperty;function g(){}g.prototype=c;var m=new g;function f(e){if("function"!==typeof e||!e.displayName)throw new Error("Expected `function` for `grammar`, got `"+e+"`");void 0===m.languages[e.displayName]&&e(m)}e.exports=m,m.highlight=function(e,t){var n,a=c.highlight;if("string"!==typeof e)throw new Error("Expected `string` for `value`, got `"+e+"`");if("Object"===m.util.type(t))n=t,t=null;else{if("string"!==typeof t)throw new Error("Expected `string` for `name`, got `"+t+"`");if(!p.call(m.languages,t))throw new Error("Unknown language: `"+t+"` is not registered");n=m.languages[t]}return a.call(this,e,n,t)},m.register=f,m.alias=function(e,t){var n,a,r,o,l=m.languages,c=e;t&&((c={})[e]=t);for(n in c)for(r=(a="string"===typeof(a=c[n])?[a]:a).length,o=-1;++o{"use strict";function t(e){e.languages.clike={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?(?:\*\/|$)/,lookbehind:!0,greedy:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0,greedy:!0}],string:{pattern:/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0},"class-name":{pattern:/(\b(?:class|extends|implements|instanceof|interface|new|trait)\s+|\bcatch\s+\()[\w.\\]+/i,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:break|catch|continue|do|else|finally|for|function|if|in|instanceof|new|null|return|throw|try|while)\b/,boolean:/\b(?:false|true)\b/,function:/\b\w+(?=\()/,number:/\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?/i,operator:/[<>]=?|[!=]=?=?|--?|\+\+?|&&?|\|\|?|[?*/~^%]/,punctuation:/[{}[\];(),.:]/}}e.exports=t,t.displayName="clike",t.aliases=[]},61993:e=>{"use strict";function t(e){!function(e){var t=/(?:"(?:\\(?:\r\n|[\s\S])|[^"\\\r\n])*"|'(?:\\(?:\r\n|[\s\S])|[^'\\\r\n])*')/;e.languages.css={comment:/\/\*[\s\S]*?\*\//,atrule:{pattern:/@[\w-](?:[^;{\s]|\s+(?![\s{]))*(?:;|(?=\s*\{))/,inside:{rule:/^@[\w-]+/,"selector-function-argument":{pattern:/(\bselector\s*\(\s*(?![\s)]))(?:[^()\s]|\s+(?![\s)])|\((?:[^()]|\([^()]*\))*\))+(?=\s*\))/,lookbehind:!0,alias:"selector"},keyword:{pattern:/(^|[^\w-])(?:and|not|only|or)(?![\w-])/,lookbehind:!0}}},url:{pattern:RegExp("\\burl\\((?:"+t.source+"|"+/(?:[^\\\r\n()"']|\\[\s\S])*/.source+")\\)","i"),greedy:!0,inside:{function:/^url/i,punctuation:/^\(|\)$/,string:{pattern:RegExp("^"+t.source+"$"),alias:"url"}}},selector:{pattern:RegExp("(^|[{}\\s])[^{}\\s](?:[^{};\"'\\s]|\\s+(?![\\s{])|"+t.source+")*(?=\\s*\\{)"),lookbehind:!0},string:{pattern:t,greedy:!0},property:{pattern:/(^|[^-\w\xA0-\uFFFF])(?!\s)[-_a-z\xA0-\uFFFF](?:(?!\s)[-\w\xA0-\uFFFF])*(?=\s*:)/i,lookbehind:!0},important:/!important\b/i,function:{pattern:/(^|[^-a-z0-9])[-a-z0-9]+(?=\()/i,lookbehind:!0},punctuation:/[(){};:,]/},e.languages.css.atrule.inside.rest=e.languages.css;var n=e.languages.markup;n&&(n.tag.addInlined("style","css"),n.tag.addAttribute("style","css"))}(e)}e.exports=t,t.displayName="css",t.aliases=[]},50683:e=>{"use strict";function t(e){e.languages.javascript=e.languages.extend("clike",{"class-name":[e.languages.clike["class-name"],{pattern:/(^|[^$\w\xA0-\uFFFF])(?!\s)[_$A-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\.(?:constructor|prototype))/,lookbehind:!0}],keyword:[{pattern:/((?:^|\})\s*)catch\b/,lookbehind:!0},{pattern:/(^|[^.]|\.\.\.\s*)\b(?:as|assert(?=\s*\{)|async(?=\s*(?:function\b|\(|[$\w\xA0-\uFFFF]|$))|await|break|case|class|const|continue|debugger|default|delete|do|else|enum|export|extends|finally(?=\s*(?:\{|$))|for|from(?=\s*(?:['"]|$))|function|(?:get|set)(?=\s*(?:[#\[$\w\xA0-\uFFFF]|$))|if|implements|import|in|instanceof|interface|let|new|null|of|package|private|protected|public|return|static|super|switch|this|throw|try|typeof|undefined|var|void|while|with|yield)\b/,lookbehind:!0}],function:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*(?:\.\s*(?:apply|bind|call)\s*)?\()/,number:{pattern:RegExp(/(^|[^\w$])/.source+"(?:"+/NaN|Infinity/.source+"|"+/0[bB][01]+(?:_[01]+)*n?/.source+"|"+/0[oO][0-7]+(?:_[0-7]+)*n?/.source+"|"+/0[xX][\dA-Fa-f]+(?:_[\dA-Fa-f]+)*n?/.source+"|"+/\d+(?:_\d+)*n/.source+"|"+/(?:\d+(?:_\d+)*(?:\.(?:\d+(?:_\d+)*)?)?|\.\d+(?:_\d+)*)(?:[Ee][+-]?\d+(?:_\d+)*)?/.source+")"+/(?![\w$])/.source),lookbehind:!0},operator:/--|\+\+|\*\*=?|=>|&&=?|\|\|=?|[!=]==|<<=?|>>>?=?|[-+*/%&|^!=<>]=?|\.{3}|\?\?=?|\?\.?|[~:]/}),e.languages.javascript["class-name"][0].pattern=/(\b(?:class|extends|implements|instanceof|interface|new)\s+)[\w.\\]+/,e.languages.insertBefore("javascript","keyword",{regex:{pattern:/((?:^|[^$\w\xA0-\uFFFF."'\])\s]|\b(?:return|yield))\s*)\/(?:\[(?:[^\]\\\r\n]|\\.)*\]|\\.|[^/\\\[\r\n])+\/[dgimyus]{0,7}(?=(?:\s|\/\*(?:[^*]|\*(?!\/))*\*\/)*(?:$|[\r\n,.;:})\]]|\/\/))/,lookbehind:!0,greedy:!0,inside:{"regex-source":{pattern:/^(\/)[\s\S]+(?=\/[a-z]*$)/,lookbehind:!0,alias:"language-regex",inside:e.languages.regex},"regex-delimiter":/^\/|\/$/,"regex-flags":/^[a-z]+$/}},"function-variable":{pattern:/#?(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*[=:]\s*(?:async\s*)?(?:\bfunction\b|(?:\((?:[^()]|\([^()]*\))*\)|(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)\s*=>))/,alias:"function"},parameter:[{pattern:/(function(?:\s+(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*)?\s*\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\))/,lookbehind:!0,inside:e.languages.javascript},{pattern:/(^|[^$\w\xA0-\uFFFF])(?!\s)[_$a-z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*=>)/i,lookbehind:!0,inside:e.languages.javascript},{pattern:/(\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\)\s*=>)/,lookbehind:!0,inside:e.languages.javascript},{pattern:/((?:\b|\s|^)(?!(?:as|async|await|break|case|catch|class|const|continue|debugger|default|delete|do|else|enum|export|extends|finally|for|from|function|get|if|implements|import|in|instanceof|interface|let|new|null|of|package|private|protected|public|return|set|static|super|switch|this|throw|try|typeof|undefined|var|void|while|with|yield)(?![$\w\xA0-\uFFFF]))(?:(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*\s*)\(\s*|\]\s*\(\s*)(?!\s)(?:[^()\s]|\s+(?![\s)])|\([^()]*\))+(?=\s*\)\s*\{)/,lookbehind:!0,inside:e.languages.javascript}],constant:/\b[A-Z](?:[A-Z_]|\dx?)*\b/}),e.languages.insertBefore("javascript","string",{hashbang:{pattern:/^#!.*/,greedy:!0,alias:"comment"},"template-string":{pattern:/`(?:\\[\s\S]|\$\{(?:[^{}]|\{(?:[^{}]|\{[^}]*\})*\})+\}|(?!\$\{)[^\\`])*`/,greedy:!0,inside:{"template-punctuation":{pattern:/^`|`$/,alias:"string"},interpolation:{pattern:/((?:^|[^\\])(?:\\{2})*)\$\{(?:[^{}]|\{(?:[^{}]|\{[^}]*\})*\})+\}/,lookbehind:!0,inside:{"interpolation-punctuation":{pattern:/^\$\{|\}$/,alias:"punctuation"},rest:e.languages.javascript}},string:/[\s\S]+/}},"string-property":{pattern:/((?:^|[,{])[ \t]*)(["'])(?:\\(?:\r\n|[\s\S])|(?!\2)[^\\\r\n])*\2(?=\s*:)/m,lookbehind:!0,greedy:!0,alias:"property"}}),e.languages.insertBefore("javascript","operator",{"literal-property":{pattern:/((?:^|[,{])[ \t]*)(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*:)/m,lookbehind:!0,alias:"property"}}),e.languages.markup&&(e.languages.markup.tag.addInlined("script","javascript"),e.languages.markup.tag.addAttribute(/on(?:abort|blur|change|click|composition(?:end|start|update)|dblclick|error|focus(?:in|out)?|key(?:down|up)|load|mouse(?:down|enter|leave|move|out|over|up)|reset|resize|scroll|select|slotchange|submit|unload|wheel)/.source,"javascript")),e.languages.js=e.languages.javascript}e.exports=t,t.displayName="javascript",t.aliases=["js"]},33592:e=>{"use strict";function t(e){e.languages.markup={comment:{pattern://,greedy:!0},prolog:{pattern:/<\?[\s\S]+?\?>/,greedy:!0},doctype:{pattern:/"'[\]]|"[^"]*"|'[^']*')+(?:\[(?:[^<"'\]]|"[^"]*"|'[^']*'|<(?!!--)|)*\]\s*)?>/i,greedy:!0,inside:{"internal-subset":{pattern:/(^[^\[]*\[)[\s\S]+(?=\]>$)/,lookbehind:!0,greedy:!0,inside:null},string:{pattern:/"[^"]*"|'[^']*'/,greedy:!0},punctuation:/^$|[[\]]/,"doctype-tag":/^DOCTYPE/i,name:/[^\s<>'"]+/}},cdata:{pattern://i,greedy:!0},tag:{pattern:/<\/?(?!\d)[^\s>\/=$<%]+(?:\s(?:\s*[^\s>\/=]+(?:\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))|(?=[\s/>])))+)?\s*\/?>/,greedy:!0,inside:{tag:{pattern:/^<\/?[^\s>\/]+/,inside:{punctuation:/^<\/?/,namespace:/^[^\s>\/:]+:/}},"special-attr":[],"attr-value":{pattern:/=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+)/,inside:{punctuation:[{pattern:/^=/,alias:"attr-equals"},/"|'/]}},punctuation:/\/?>/,"attr-name":{pattern:/[^\s>\/]+/,inside:{namespace:/^[^\s>\/:]+:/}}}},entity:[{pattern:/&[\da-z]{1,8};/i,alias:"named-entity"},/&#x?[\da-f]{1,8};/i]},e.languages.markup.tag.inside["attr-value"].inside.entity=e.languages.markup.entity,e.languages.markup.doctype.inside["internal-subset"].inside=e.languages.markup,e.hooks.add("wrap",(function(e){"entity"===e.type&&(e.attributes.title=e.content.value.replace(/&/,"&"))})),Object.defineProperty(e.languages.markup.tag,"addInlined",{value:function(t,n){var a={};a["language-"+n]={pattern:/(^$)/i,lookbehind:!0,inside:e.languages[n]},a.cdata=/^$/i;var r={"included-cdata":{pattern://i,inside:a}};r["language-"+n]={pattern:/[\s\S]+/,inside:e.languages[n]};var o={};o[t]={pattern:RegExp(/(<__[^>]*>)(?:))*\]\]>|(?!)/.source.replace(/__/g,(function(){return t})),"i"),lookbehind:!0,greedy:!0,inside:r},e.languages.insertBefore("markup","cdata",o)}}),Object.defineProperty(e.languages.markup.tag,"addAttribute",{value:function(t,n){e.languages.markup.tag.inside["special-attr"].push({pattern:RegExp(/(^|["'\s])/.source+"(?:"+t+")"+/\s*=\s*(?:"[^"]*"|'[^']*'|[^\s'">=]+(?=[\s>]))/.source,"i"),lookbehind:!0,inside:{"attr-name":/^[^\s=]+/,"attr-value":{pattern:/=[\s\S]+/,inside:{value:{pattern:/(^=\s*(["']|(?!["'])))\S[\s\S]*(?=\2$)/,lookbehind:!0,alias:[n,"language-"+n],inside:e.languages[n]},punctuation:[{pattern:/^=/,alias:"attr-equals"},/"|'/]}}}})}}),e.languages.html=e.languages.markup,e.languages.mathml=e.languages.markup,e.languages.svg=e.languages.markup,e.languages.xml=e.languages.extend("markup",{}),e.languages.ssml=e.languages.xml,e.languages.atom=e.languages.xml,e.languages.rss=e.languages.xml}e.exports=t,t.displayName="markup",t.aliases=["html","mathml","svg","xml","ssml","atom","rss"]},93915:(e,t,n)=>{var a=function(e){var t=/(?:^|\s)lang(?:uage)?-([\w-]+)(?=\s|$)/i,n=0,a={},r={manual:e.Prism&&e.Prism.manual,disableWorkerMessageHandler:e.Prism&&e.Prism.disableWorkerMessageHandler,util:{encode:function e(t){return t instanceof o?new o(t.type,e(t.content),t.alias):Array.isArray(t)?t.map(e):t.replace(/&/g,"&").replace(/=d.reach);S+=k.value.length,k=k.next){var A=k.value;if(t.length>e.length)return;if(!(A instanceof o)){var F,O=1;if(b){if(!(F=l(x,S,e,y))||F.index>=e.length)break;var N=F.index,C=F.index+F[0].length,j=S;for(j+=k.value.length;N>=j;)j+=(k=k.next).value.length;if(S=j-=k.value.length,k.value instanceof o)continue;for(var P=k;P!==t.tail&&(jd.reach&&(d.reach=z);var M=k.prev;if(_&&(M=s(t,M,_),S+=_.length),u(t,M,O),k=s(t,M,new o(p,h?r.tokenize(L,h):L,v,L)),E&&s(t,k,E),O>1){var T={cause:p+","+m,reach:z};c(e,t,n,k.prev,S,T),d&&T.reach>d.reach&&(d.reach=T.reach)}}}}}}function i(){var e={value:null,prev:null,next:null},t={value:null,prev:e,next:null};e.next=t,this.head=e,this.tail=t,this.length=0}function s(e,t,n){var a=t.next,r={value:n,prev:t,next:a};return t.next=r,a.prev=r,e.length++,r}function u(e,t,n){for(var a=t.next,r=0;r"+o.content+""},!e.document)return e.addEventListener?(r.disableWorkerMessageHandler||e.addEventListener("message",(function(t){var n=JSON.parse(t.data),a=n.language,o=n.code,l=n.immediateClose;e.postMessage(r.highlight(o,r.languages[a],a)),l&&e.close()}),!1),r):r;var d=r.util.currentScript();function p(){r.manual||r.highlightAll()}if(d&&(r.filename=d.src,d.hasAttribute("data-manual")&&(r.manual=!0)),!r.manual){var g=document.readyState;"loading"===g||"interactive"===g&&d&&d.defer?document.addEventListener("DOMContentLoaded",p):window.requestAnimationFrame?window.requestAnimationFrame(p):window.setTimeout(p,16)}return r}("undefined"!==typeof window?window:"undefined"!==typeof WorkerGlobalScope&&self instanceof WorkerGlobalScope?self:{});e.exports&&(e.exports=a),"undefined"!==typeof n.g&&(n.g.Prism=a)},82140:(e,t)=>{"use strict";t.q=function(e){var t=String(e||n).trim();return t===n?[]:t.split(r)};var n="",a=" ",r=/[ \t\n\r\f]+/g},31630:e=>{e.exports=function(){for(var e={},n=0;n{"use strict";e.exports=JSON.parse('{"AElig":"\xc6","AMP":"&","Aacute":"\xc1","Acirc":"\xc2","Agrave":"\xc0","Aring":"\xc5","Atilde":"\xc3","Auml":"\xc4","COPY":"\xa9","Ccedil":"\xc7","ETH":"\xd0","Eacute":"\xc9","Ecirc":"\xca","Egrave":"\xc8","Euml":"\xcb","GT":">","Iacute":"\xcd","Icirc":"\xce","Igrave":"\xcc","Iuml":"\xcf","LT":"<","Ntilde":"\xd1","Oacute":"\xd3","Ocirc":"\xd4","Ograve":"\xd2","Oslash":"\xd8","Otilde":"\xd5","Ouml":"\xd6","QUOT":"\\"","REG":"\xae","THORN":"\xde","Uacute":"\xda","Ucirc":"\xdb","Ugrave":"\xd9","Uuml":"\xdc","Yacute":"\xdd","aacute":"\xe1","acirc":"\xe2","acute":"\xb4","aelig":"\xe6","agrave":"\xe0","amp":"&","aring":"\xe5","atilde":"\xe3","auml":"\xe4","brvbar":"\xa6","ccedil":"\xe7","cedil":"\xb8","cent":"\xa2","copy":"\xa9","curren":"\xa4","deg":"\xb0","divide":"\xf7","eacute":"\xe9","ecirc":"\xea","egrave":"\xe8","eth":"\xf0","euml":"\xeb","frac12":"\xbd","frac14":"\xbc","frac34":"\xbe","gt":">","iacute":"\xed","icirc":"\xee","iexcl":"\xa1","igrave":"\xec","iquest":"\xbf","iuml":"\xef","laquo":"\xab","lt":"<","macr":"\xaf","micro":"\xb5","middot":"\xb7","nbsp":"\xa0","not":"\xac","ntilde":"\xf1","oacute":"\xf3","ocirc":"\xf4","ograve":"\xf2","ordf":"\xaa","ordm":"\xba","oslash":"\xf8","otilde":"\xf5","ouml":"\xf6","para":"\xb6","plusmn":"\xb1","pound":"\xa3","quot":"\\"","raquo":"\xbb","reg":"\xae","sect":"\xa7","shy":"\xad","sup1":"\xb9","sup2":"\xb2","sup3":"\xb3","szlig":"\xdf","thorn":"\xfe","times":"\xd7","uacute":"\xfa","ucirc":"\xfb","ugrave":"\xf9","uml":"\xa8","uuml":"\xfc","yacute":"\xfd","yen":"\xa5","yuml":"\xff"}')},21257:e=>{"use strict";e.exports=JSON.parse('{"0":"\ufffd","128":"\u20ac","130":"\u201a","131":"\u0192","132":"\u201e","133":"\u2026","134":"\u2020","135":"\u2021","136":"\u02c6","137":"\u2030","138":"\u0160","139":"\u2039","140":"\u0152","142":"\u017d","145":"\u2018","146":"\u2019","147":"\u201c","148":"\u201d","149":"\u2022","150":"\u2013","151":"\u2014","152":"\u02dc","153":"\u2122","154":"\u0161","155":"\u203a","156":"\u0153","158":"\u017e","159":"\u0178"}')}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/68220.ece8573d.chunk.js b/ydb/core/viewer/monitoring/static/js/68220.ece8573d.chunk.js new file mode 100644 index 000000000000..f666be155600 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/68220.ece8573d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[68220],{41353:e=>{function t(e){e.languages.al={comment:/\/\/.*|\/\*[\s\S]*?\*\//,string:{pattern:/'(?:''|[^'\r\n])*'(?!')|"(?:""|[^"\r\n])*"(?!")/,greedy:!0},function:{pattern:/(\b(?:event|procedure|trigger)\s+|(?:^|[^.])\.\s*)[a-z_]\w*(?=\s*\()/i,lookbehind:!0},keyword:[/\b(?:array|asserterror|begin|break|case|do|downto|else|end|event|exit|for|foreach|function|if|implements|in|indataset|interface|internal|local|of|procedure|program|protected|repeat|runonclient|securityfiltering|suppressdispose|temporary|then|to|trigger|until|var|while|with|withevents)\b/i,/\b(?:action|actions|addafter|addbefore|addfirst|addlast|area|assembly|chartpart|codeunit|column|controladdin|cuegroup|customizes|dataitem|dataset|dotnet|elements|enum|enumextension|extends|field|fieldattribute|fieldelement|fieldgroup|fieldgroups|fields|filter|fixed|grid|group|key|keys|label|labels|layout|modify|moveafter|movebefore|movefirst|movelast|page|pagecustomization|pageextension|part|profile|query|repeater|report|requestpage|schema|separator|systempart|table|tableelement|tableextension|textattribute|textelement|type|usercontrol|value|xmlport)\b/i],number:/\b(?:0x[\da-f]+|(?:\d+(?:\.\d*)?|\.\d+)(?:e[+-]?\d+)?)(?:F|LL?|U(?:LL?)?)?\b/i,boolean:/\b(?:false|true)\b/i,variable:/\b(?:Curr(?:FieldNo|Page|Report)|x?Rec|RequestOptionsPage)\b/,"class-name":/\b(?:automation|biginteger|bigtext|blob|boolean|byte|char|clienttype|code|completiontriggererrorlevel|connectiontype|database|dataclassification|datascope|date|dateformula|datetime|decimal|defaultlayout|dialog|dictionary|dotnetassembly|dotnettypedeclaration|duration|errorinfo|errortype|executioncontext|executionmode|fieldclass|fieldref|fieldtype|file|filterpagebuilder|guid|httpclient|httpcontent|httpheaders|httprequestmessage|httpresponsemessage|instream|integer|joker|jsonarray|jsonobject|jsontoken|jsonvalue|keyref|list|moduledependencyinfo|moduleinfo|none|notification|notificationscope|objecttype|option|outstream|pageresult|record|recordid|recordref|reportformat|securityfilter|sessionsettings|tableconnectiontype|tablefilter|testaction|testfield|testfilterfield|testpage|testpermissions|testrequestpage|text|textbuilder|textconst|textencoding|time|transactionmodel|transactiontype|variant|verbosity|version|view|views|webserviceactioncontext|webserviceactionresultcode|xmlattribute|xmlattributecollection|xmlcdata|xmlcomment|xmldeclaration|xmldocument|xmldocumenttype|xmlelement|xmlnamespacemanager|xmlnametable|xmlnode|xmlnodelist|xmlprocessinginstruction|xmlreadoptions|xmltext|xmlwriteoptions)\b/i,operator:/\.\.|:[=:]|[-+*/]=?|<>|[<>]=?|=|\b(?:and|div|mod|not|or|xor)\b/i,punctuation:/[()\[\]{}:.;,]/}}e.exports=t,t.displayName="al",t.aliases=[]},68220:(e,t,o)=>{o.d(t,{default:()=>i});var a=o(41353);const i=o.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6833.584b7806.chunk.js b/ydb/core/viewer/monitoring/static/js/6833.584b7806.chunk.js deleted file mode 100644 index 1aaf6992a9a3..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6833.584b7806.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6833],{26833:function(e,_,i){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var i=_(e),n={name:"fr-ch",weekdays:"dimanche_lundi_mardi_mercredi_jeudi_vendredi_samedi".split("_"),months:"janvier_f\xe9vrier_mars_avril_mai_juin_juillet_ao\xfbt_septembre_octobre_novembre_d\xe9cembre".split("_"),weekStart:1,weekdaysShort:"dim._lun._mar._mer._jeu._ven._sam.".split("_"),monthsShort:"janv._f\xe9vr._mars_avr._mai_juin_juil._ao\xfbt_sept._oct._nov._d\xe9c.".split("_"),weekdaysMin:"di_lu_ma_me_je_ve_sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"dans %s",past:"il y a %s",s:"quelques secondes",m:"une minute",mm:"%d minutes",h:"une heure",hh:"%d heures",d:"un jour",dd:"%d jours",M:"un mois",MM:"%d mois",y:"un an",yy:"%d ans"}};return i.default.locale(n,null,!0),n}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/68377.f73a91b7.chunk.js b/ydb/core/viewer/monitoring/static/js/68377.f73a91b7.chunk.js new file mode 100644 index 000000000000..6a9c44ee04d0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/68377.f73a91b7.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[68377],{1022:e=>{function n(e){!function(e){var n=/\$(?:\w[a-z\d]*(?:_[^\x00-\x1F\s"'\\()$]*)?|\{[^}\s"'\\]+\})/i;e.languages.nginx={comment:{pattern:/(^|[\s{};])#.*/,lookbehind:!0,greedy:!0},directive:{pattern:/(^|\s)\w(?:[^;{}"'\\\s]|\\.|"(?:[^"\\]|\\.)*"|'(?:[^'\\]|\\.)*'|\s+(?:#.*(?!.)|(?![#\s])))*?(?=\s*[;{])/,lookbehind:!0,greedy:!0,inside:{string:{pattern:/((?:^|[^\\])(?:\\\\)*)(?:"(?:[^"\\]|\\.)*"|'(?:[^'\\]|\\.)*')/,lookbehind:!0,greedy:!0,inside:{escape:{pattern:/\\["'\\nrt]/,alias:"entity"},variable:n}},comment:{pattern:/(\s)#.*/,lookbehind:!0,greedy:!0},keyword:{pattern:/^\S+/,greedy:!0},boolean:{pattern:/(\s)(?:off|on)(?!\S)/,lookbehind:!0},number:{pattern:/(\s)\d+[a-z]*(?!\S)/i,lookbehind:!0},variable:n}},punctuation:/[{};]/}}(e)}e.exports=n,n.displayName="nginx",n.aliases=[]},68377:(e,n,a)=>{a.d(n,{default:()=>i});var t=a(1022);const i=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/684.7c31509b.chunk.js b/ydb/core/viewer/monitoring/static/js/684.7c31509b.chunk.js deleted file mode 100644 index 9274af72cd23..000000000000 --- a/ydb/core/viewer/monitoring/static/js/684.7c31509b.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[684],{22983:(e,t,s)=>{s.d(t,{B:()=>d});var i=s(59284),n=s(84476),o=s(84375),a=s(55974),l=s(42829),r=s(60712);function d({children:e,onConfirmAction:t,onConfirmActionSuccess:s,dialogHeader:d,dialogText:c,retryButtonText:u,buttonDisabled:m=!1,buttonView:p="action",buttonTitle:h,buttonClassName:v,withPopover:g=!1,popoverContent:f,popoverPlacement:b="right",popoverDisabled:x=!0}){const[k,y]=i.useState(!1),[j,N]=i.useState(!1),[S,w]=i.useState(!1),D=()=>(0,r.jsx)(n.$,{onClick:()=>y(!0),view:p,disabled:m,loading:!m&&j,className:v,title:h,children:e});return(0,r.jsxs)(i.Fragment,{children:[(0,r.jsx)(a.g,{visible:k,header:d,text:c,withRetry:S,retryButtonText:u,onConfirm:async e=>{N(!0),await t(e)},onConfirmActionSuccess:async()=>{w(!1);try{await(null===s||void 0===s?void 0:s())}finally{N(!1)}},onConfirmActionError:e=>{w((0,l.D)(e)),N(!1)},onClose:()=>{y(!1)}}),g?(0,r.jsx)(o.A,{content:f,placement:b,disabled:x,children:D()}):D()]})}},55974:(e,t,s)=>{s.d(t,{g:()=>f});var i=s(59284),n=s(18677),o=s(71153),a=s(74321),l=s(2198),r=s(99991),d=s(89954),c=s(77506),u=s(48372);const m=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),p=(0,u.g4)("ydb-critical-action-dialog",{en:m});var h=s(60712);const v=(0,c.cn)("ydb-critical-dialog"),g=e=>e.data&&"issues"in e.data&&e.data.issues?(0,h.jsx)(d.O,{hideSeverity:!0,data:e.data}):403===e.status?p("no-rights-error"):e.statusText?e.statusText:p("default-error");function f({visible:e,header:t,text:s,withRetry:d,retryButtonText:c,withCheckBox:u,onClose:m,onConfirm:f,onConfirmActionSuccess:b,onConfirmActionError:x}){const[k,y]=i.useState(!1),[j,N]=i.useState(),[S,w]=i.useState(!1),D=async e=>(y(!0),f(e).then((()=>{b(),m()})).catch((e=>{x(e),N(e)})).finally((()=>{y(!1)})));return(0,h.jsx)(l.l,{open:e,hasCloseButton:!1,className:v(),size:"s",onClose:m,onTransitionExited:()=>{N(void 0),w(!1)},children:j?(0,h.jsxs)(i.Fragment,{children:[(0,h.jsx)(l.l.Header,{caption:t}),(0,h.jsx)(l.l.Body,{className:v("body"),children:(0,h.jsxs)("div",{className:v("body-message",{error:!0}),children:[(0,h.jsx)("span",{className:v("error-icon"),children:(0,h.jsx)(n.A,{width:"24",height:"22"})}),g(j)]})}),(0,h.jsx)(l.l.Footer,{loading:!1,preset:"default",textButtonApply:d?c||p("button-retry"):void 0,textButtonCancel:p("button-close"),onClickButtonApply:()=>D(!0),onClickButtonCancel:m})]}):(0,h.jsxs)(i.Fragment,{children:[(0,h.jsx)(l.l.Header,{caption:t}),(0,h.jsxs)(l.l.Body,{className:v("body"),children:[(0,h.jsxs)("div",{className:v("body-message",{warning:!0}),children:[(0,h.jsx)("span",{className:v("warning-icon"),children:(0,h.jsx)(r.I,{data:o.A,size:24})}),s]}),u?(0,h.jsx)(a.S,{checked:S,onUpdate:w,children:p("checkbox-text")}):null]}),(0,h.jsx)(l.l.Footer,{loading:k,preset:"default",textButtonApply:p("button-confirm"),textButtonCancel:p("button-cancel"),propsButtonApply:{type:"submit",disabled:u&&!S},onClickButtonCancel:m,onClickButtonApply:()=>D()})]})})}},42829:(e,t,s)=>{s.d(t,{D:()=>i});const i=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},3685:(e,t,s)=>{s.d(t,{$:()=>l});var i=s(77506),n=s(33775),o=s(60712);const a=(0,i.cn)("ydb-entity-page-title");function l({entityName:e,status:t,id:s,className:i}){return(0,o.jsxs)("div",{className:a(null,i),children:[(0,o.jsx)("span",{className:a("prefix"),children:e}),(0,o.jsx)(n.k,{className:a("icon"),status:t,size:"s"}),s]})}},42655:(e,t,s)=>{s.d(t,{y:()=>c});var i=s(59284),n=s(89169),o=s(77506),a=s(66781),l=s(60712);const r=(0,o.cn)("ydb-info-viewer-skeleton"),d=()=>(0,l.jsxs)("div",{className:r("label"),children:[(0,l.jsx)(n.E,{className:r("label__text")}),(0,l.jsx)("div",{className:r("label__dots")})]}),c=({rows:e=8,className:t,delay:s=600})=>{const[o]=(0,a.y)(s);let c=(0,l.jsxs)(i.Fragment,{children:[(0,l.jsx)(d,{}),(0,l.jsx)(n.E,{className:r("value")})]});return o||(c=null),(0,l.jsx)("div",{className:r(null,t),children:[...new Array(e)].map(((e,t)=>(0,l.jsx)("div",{className:r("row"),children:c},`skeleton-row-${t}`)))})}},56735:(e,t,s)=>{s.d(t,{Q:()=>y});var i=s(87184),n=s(92459),o=s(78668),a=s(7435),l=s(46549),r=s(77506),d=s(56839),c=s(31684),u=s(90182),m=s(18863),p=s(25196),h=s(15132),v=s(33775),g=s(48372);const f=JSON.parse('{"type":"Type","path":"Path","guid":"GUID","serial-number":"Serial Number","shared-with-os":"SharedWithOs","drive-status":"Drive Status","state":"State","device":"Device","realtime":"Realtime","space":"Space","slots":"Slots","log-size":"Log Size","system-size":"System Size","links":"Links","developer-ui":"Developer UI","pdisk-page":"PDisk page","yes":"Yes"}'),b=(0,g.g4)("ydb-pDisk-info",{en:f});var x=s(60712);const k=(0,r.cn)("ydb-pdisk-info");function y({pDisk:e,nodeId:t,withPDiskPageLink:s,className:r}){const g=(0,u.N4)(o._5),[f,y,j,N]=function({pDisk:e,nodeId:t,withPDiskPageLink:s,isUserAllowedToMakeChanges:i}){const{PDiskId:o,Path:r,Guid:u,Category:m,Type:g,Device:f,Realtime:y,State:j,SerialNumber:N,TotalSize:S,AllocatedSize:w,StatusV2:D,NumActiveSlots:I,ExpectedSlotCount:C,LogUsedSize:T,LogTotalSize:E,SystemSize:P,SharedWithOs:z}=e||{},A=[];(0,a.f8)(m)&&A.push({label:b("type"),value:g}),(0,a.f8)(r)&&A.push({label:b("path"),value:r}),(0,a.f8)(u)&&A.push({label:b("guid"),value:u}),N&&A.push({label:b("serial-number"),value:N}),(0,a.f8)(z)&&A.push({label:b("shared-with-os"),value:b("yes")});const _=[];(0,a.f8)(D)&&_.push({label:b("drive-status"),value:D}),(0,a.f8)(j)&&_.push({label:b("state"),value:j}),(0,a.f8)(f)&&_.push({label:b("device"),value:(0,x.jsx)(v.k,{status:f})}),(0,a.f8)(y)&&_.push({label:b("realtime"),value:(0,x.jsx)(v.k,{status:y})});const M=[];M.push({label:b("space"),value:(0,x.jsx)(h.O,{value:w,capacity:S,formatValues:d.vX,colorizeProgress:!0})}),(0,a.f8)(I)&&(0,a.f8)(C)&&M.push({label:b("slots"),value:(0,x.jsx)(h.O,{value:I,capacity:C})}),(0,a.f8)(T)&&(0,a.f8)(E)&&M.push({label:b("log-size"),value:(0,x.jsx)(h.O,{value:T,capacity:E,formatValues:d.vX})}),(0,a.f8)(P)&&M.push({label:b("system-size"),value:(0,l.z3)({value:P})});const O=[];if((s||i)&&(0,a.f8)(o)&&(0,a.f8)(t)){const e=(0,n.Ck)(o,t),a=(0,c.ar)({nodeId:t,pDiskId:o});O.push({label:b("links"),value:(0,x.jsxs)("span",{className:k("links"),children:[s&&(0,x.jsx)(p.K,{title:b("pdisk-page"),url:e,external:!1}),i&&(0,x.jsx)(p.K,{title:b("developer-ui"),url:a})]})})}return[A,_,M,O]}({pDisk:e,nodeId:t,withPDiskPageLink:s,isUserAllowedToMakeChanges:g});return(0,x.jsxs)(i.s,{className:r,gap:2,direction:"row",wrap:!0,children:[(0,x.jsxs)(i.s,{direction:"column",gap:2,width:500,children:[(0,x.jsx)(m.z,{info:f,renderEmptyState:()=>null}),(0,x.jsx)(m.z,{info:j,renderEmptyState:()=>null})]}),(0,x.jsxs)(i.s,{direction:"column",gap:2,width:500,children:[(0,x.jsx)(m.z,{info:y,renderEmptyState:()=>null}),(0,x.jsx)(m.z,{info:N,renderEmptyState:()=>null})]})]})}},58389:(e,t,s)=>{s.d(t,{B:()=>c});var i=s(87184),n=s(77506),o=s(90053),a=s(70043),l=s(60712);const r=(0,n.cn)("ydb-page-meta");function d({items:e,loading:t}){return(0,l.jsx)("div",{className:r("info"),children:t?(0,l.jsx)(a.E,{className:r("skeleton")}):e.filter((e=>Boolean(e))).join("\xa0\xa0\xb7\xa0\xa0")})}function c({className:e,...t}){return(0,l.jsxs)(i.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:r(null,e),children:[(0,l.jsx)(d,{...t}),(0,l.jsx)(o.E,{})]})}},70043:(e,t,s)=>{s.d(t,{E:()=>a});var i=s(89169),n=s(66781),o=s(60712);const a=({delay:e=600,className:t})=>{const[s]=(0,n.y)(e);return s?(0,o.jsx)(i.E,{className:t}):null}},67440:(e,t,s)=>{s.d(t,{E:()=>y});s(59284);var i=s(92459),n=s(78668),o=s(7435),a=s(77506),l=s(56839),r=s(31684),d=s(7187),c=s(90182),u=s(41650),m=s(60073),p=s(25196),h=s(15132),v=s(33775),g=s(48372);const f=JSON.parse('{"slot-id":"VDisk Slot Id","pool-name":"Storage Pool Name","kind":"Kind","guid":"GUID","incarnation-guid":"Incarnation GUID","instance-guid":"Instance GUID","replication-status":"Replicated","state-status":"VDisk State","space-status":"Disk Space","fresh-rank-satisfaction":"Fresh Rank Satisfaction","level-rank-satisfaction":"Level Rank Satisfaction","front-queues":"Front Queues","has-unreadable-blobs":"Has Unreadable Blobs","size":"Size","read-throughput":"Read Throughput","write-throughput":"Write Throughput","links":"Links","vdisk-page":"VDisk Page","developer-ui":"Developer UI","yes":"Yes","no":"No","vdiks-title":"VDisk"}'),b=(0,g.g4)("ydb-vDisk-info",{en:f});var x=s(60712);const k=(0,a.cn)("ydb-vdisk-info");function y({data:e,withVDiskPageLink:t,withTitle:s,...a}){var d,g;const f=(0,c.N4)(n._5),{AllocatedSize:y,DiskSpace:N,FrontQueues:S,Guid:w,Replicated:D,VDiskState:I,VDiskSlotId:C,Kind:T,SatisfactionRank:E,AvailableSize:P,HasUnreadableBlobs:z,IncarnationGuid:A,InstanceGuid:_,StoragePoolName:M,ReadThroughput:O,WriteThroughput:R,PDiskId:L,NodeId:B}=e||{},F=[];var V,$;((0,o.f8)(C)&&F.push({label:b("slot-id"),value:C}),(0,o.f8)(M)&&F.push({label:b("pool-name"),value:M}),(0,o.f8)(I)&&F.push({label:b("state-status"),value:I}),Number(y)>=0&&Number(P)>=0&&F.push({label:b("size"),value:(0,x.jsx)(h.O,{value:y,capacity:Number(y)+Number(P),formatValues:l.vX,colorizeProgress:!0})}),(0,o.f8)(T)&&F.push({label:b("kind"),value:T}),(0,o.f8)(w)&&F.push({label:b("guid"),value:w}),(0,o.f8)(A)&&F.push({label:b("incarnation-guid"),value:A}),(0,o.f8)(_)&&F.push({label:b("instance-guid"),value:_}),(0,o.f8)(D)&&F.push({label:b("replication-status"),value:b(D?"yes":"no")}),(0,o.f8)(N)&&F.push({label:b("space-status"),value:(0,x.jsx)(v.k,{status:N})}),(0,o.f8)(null===E||void 0===E||null===(d=E.FreshRank)||void 0===d?void 0:d.Flag))&&F.push({label:b("fresh-rank-satisfaction"),value:(0,x.jsx)(v.k,{status:null===E||void 0===E||null===(V=E.FreshRank)||void 0===V?void 0:V.Flag})});(0,o.f8)(null===E||void 0===E||null===(g=E.LevelRank)||void 0===g?void 0:g.Flag)&&F.push({label:b("level-rank-satisfaction"),value:(0,x.jsx)(v.k,{status:null===E||void 0===E||null===($=E.LevelRank)||void 0===$?void 0:$.Flag})});(0,o.f8)(S)&&F.push({label:b("front-queues"),value:(0,x.jsx)(v.k,{status:S})}),(0,o.f8)(z)&&F.push({label:b("has-unreadable-blobs"),value:b(z?"yes":"no")}),(0,o.f8)(O)&&F.push({label:b("read-throughput"),value:(0,u.O4)(O)}),(0,o.f8)(R)&&F.push({label:b("write-throughput"),value:(0,u.O4)(R)});if((0,o.f8)(L)&&(0,o.f8)(B)&&(0,o.f8)(C)){const e=[];if(t){const t=(0,i.yX)(C,L,B);e.push((0,x.jsx)(p.K,{title:b("vdisk-page"),url:t,external:!1},t))}if(f){const t=(0,r.Wg)({nodeId:B,pDiskId:L,vDiskSlotId:C});e.push((0,x.jsx)(p.K,{title:b("developer-ui"),url:t},t))}e.length&&F.push({label:b("links"),value:(0,x.jsx)("div",{className:k("links"),children:e})})}const U=e&&s?(0,x.jsx)(j,{data:e}):null;return(0,x.jsx)(m.z_,{info:F,title:U,...a})}function j({data:e}){return(0,x.jsxs)("div",{className:k("title"),children:[b("vdiks-title"),(0,x.jsx)(v.k,{status:(0,d.XY)(e.Severity)}),e.StringifiedId]})}},69134:(e,t,s)=>{s.r(t),s.d(t,{PDiskPage:()=>ke});var i=s(59284),n=s(76938),o=s(99991),a=s(23871),l=s(44992),r=s(61750),d=s(67087),c=s(370),u=s(22983),m=s(3685),p=s(44508),h=s(42655),v=s(82015),g=s(56735),f=s(58389),b=s(92459),x=s(21334),k=s(78668),y=s(67028),j=s(40174),N=s(7187),S=s(68712),w=s(7435),D=s(27295),I=s(78034);const C=x.F.injectEndpoints({endpoints:e=>({getPdiskInfo:e.query({queryFn:async({nodeId:e,pDiskId:t},{signal:s,getState:i,dispatch:n})=>{let o;o=await(0,S.FC)("/pdisk/info",void 0,{getState:i,dispatch:n})>0?window.api.pdisk.getPDiskInfo({nodeId:e,pDiskId:t},{signal:s}):window.api.viewer.getNodeWhiteboardPDiskInfo({nodeId:e,pDiskId:t},{signal:s}).then((e=>e.PDiskStateInfo?{Whiteboard:{PDisk:{...e.PDiskStateInfo[0],ExpectedSlotCount:void 0}}}:{}));try{const t=await Promise.all([o,window.api.viewer.getNodeInfo(e,{signal:s})]);return{data:function([e={},t]){var s,i,n;const o=null===(s=t.SystemStateInfo)||void 0===s?void 0:s[0],a=(0,I.q1)(o),{BSC:l={},Whiteboard:r={}}=e||{},{PDisk:d={},VDisks:c=[]}=r,{PDisk:u={}}=l,m=(0,D.or)({...u,...d}),p=null!==(i=m.NodeId)&&void 0!==i?i:a.NodeId,{LogUsedSize:h,LogTotalSize:v,TotalSize:g,SystemSize:f,ExpectedSlotCount:b,EnforcedDynamicSlotSize:x}=m;let k;(0,w.f8)(v)&&(k={SlotType:"log",Used:Number(h),Total:Number(v),UsagePercent:100*Number(h)/Number(v),Severity:1,SlotData:{LogUsedSize:h,LogTotalSize:v,SystemSize:f}});const y=c.map((e=>(0,D.WT)({...e,NodeId:p})));y.sort(((e,t)=>Number(t.VDiskSlotId)-Number(e.VDiskSlotId)));const j=y.map((e=>{var t;return{SlotType:"vDisk",Id:null===(t=e.VDiskId)||void 0===t?void 0:t.GroupID,Title:e.StoragePoolName,Severity:e.Severity,Used:Number(e.AllocatedSize),Total:Number(e.TotalSize),UsagePercent:e.AllocatedPercent,SlotData:e}}));let N=[];if(b&&b>j.length){const e=b-j.length;let t=Number(x);if(isNaN(t)){const s=j.reduce(((e,t)=>t.Total?e+t.Total:e),0);t=(Number(g)-s-Number(v))/e}N=(0,w._e)(e).map((()=>({SlotType:"empty",Total:t,Severity:1,SlotData:{Size:t}})))}const S=[...j,...N];return k&&S.length>0&&S.unshift(k),{...m,NodeId:p,NodeHost:a.Host,NodeType:null===(n=a.Roles)||void 0===n?void 0:n[0],NodeDC:a.DC,SlotItems:S}}(t)}}catch(a){return{error:a}}},providesTags:(e,t,s)=>["All",{type:"PDiskData",id:(0,N.r$)(s.nodeId,s.pDiskId)}]})}),overrideExisting:"throw"});var T=s(77506),E=s(90182),P=s(99936),z=s(13066),A=s(40569),_=s(84375),M=s(84476),O=s(55974),R=s(42829),L=s(48372);const B=JSON.parse('{"fqdn":"FQDN","pdisk":"PDisk","node":"Node","storage":"Storage","disk-distribution":"Disk distribution","empty-slot":"Empty slot","log":"Log","label.log-size":"Log Size","label.system-size":"System Size","label.slot-size":"Slot Size","no-slots-data":"No slots data","restart-pdisk-button":"Restart PDisk","force-restart-pdisk-button":"Restart anyway","restart-pdisk-not-allowed":"You don\'t have enough rights to restart PDisk","restart-pdisk-dialog-header":"Restart PDisk","restart-pdisk-dialog-text":"PDisk will be restarted. Do you want to proceed?","decommission-none":"None","decommission-imminent":"Imminent","decommission-pending":"Pending","decommission-rejected":"Rejected","decommission-label":"{{decommission}} decommission","decommission-button":"Decommission","decommission-change-not-allowed":"You don\'t have enough rights to change PDisk decommission","decommission-dialog-title":"Change decommission status","decommission-dialog-force-change":"Change anyway","decommission-dialog-imminent-warning":"This will start imminent decommission. Existing slots will be moved from the disk","decommission-dialog-pending-warning":"This will start pending decommission. Decommission will be planned for this disk, but will not start immediatelly. Existing slots will not be moved from the disk, but no new slots will be allocated on it","decommission-dialog-rejected-warning":"This will start rejected decommission. No slots from other disks are placed on this disk in the process of decommission","decommission-dialog-none-warning":"This will reset decommission mode, allowing the disk to be used by the storage"}'),F=(0,L.g4)("ydb-pDisk-page",{en:B});var V,$,U,G;function H(){return H=Object.assign?Object.assign.bind():function(e){for(var t=1;tt("DECOMMIT_NONE"),hidden:!e||"DECOMMIT_NONE"===e||"DECOMMIT_UNSET"===e},{text:F("decommission-pending"),action:()=>t("DECOMMIT_PENDING"),hidden:"DECOMMIT_PENDING"===e},{text:F("decommission-rejected"),action:()=>t("DECOMMIT_REJECTED"),hidden:"DECOMMIT_REJECTED"===e},{text:F("decommission-imminent"),theme:"danger",action:()=>t("DECOMMIT_IMMINENT"),hidden:"DECOMMIT_IMMINENT"===e}]}(e,l);return(0,W.jsxs)(i.Fragment,{children:[(0,W.jsx)(A.r,{renderSwitcher:e=>(0,W.jsx)(Q,{popoverDisabled:o,loading:r,disabled:n,...e}),items:m,popupProps:{className:q("popup")}}),(0,W.jsx)(O.g,{visible:Boolean(a),header:F("decommission-dialog-title"),text:Y(a),withRetry:c,withCheckBox:!0,retryButtonText:F("decommission-dialog-force-change"),onConfirm:async e=>{d(!0),await t(a,e)},onConfirmActionSuccess:async()=>{u(!1),await(0,w.uk)(5e3);try{await s()}finally{d(!1)}},onConfirmActionError:e=>{u((0,R.D)(e)),d(!1)},onClose:()=>{l(void 0)}})]})}function Q({popoverDisabled:e,...t}){return(0,W.jsx)(_.A,{content:F("decommission-change-not-allowed"),placement:"right",disabled:e,children:(0,W.jsxs)(M.$,{view:"normal",className:q("button"),...t,children:[(0,W.jsx)(o.I,{data:J}),F("decommission-button"),(0,W.jsx)(o.I,{data:z.A})]})})}var K=s(47665);function Z(e){return F("decommission-label",{decommission:e})}function ee({decommission:e}){return"DECOMMIT_IMMINENT"===e?(0,W.jsx)(K.J,{theme:"danger",size:"m",children:Z(F("decommission-imminent"))}):"DECOMMIT_PENDING"===e?(0,W.jsx)(K.J,{theme:"warning",size:"m",children:Z(F("decommission-pending"))}):"DECOMMIT_REJECTED"===e?(0,W.jsx)(K.J,{theme:"normal",size:"m",children:Z(F("decommission-rejected"))}):null}var te=s(88226),se=s(13096),ie=s(60073),ne=s(44294),oe=s(15132),ae=s(67440),le=s(46549),re=s(56839);const de=(0,T.cn)("ydb-pdisk-space-distribution"),ce=40;function ue({data:e}){const{SlotItems:t}=e,{PDiskId:s,NodeId:i}=e,n=ce*((null===t||void 0===t?void 0:t.length)||1);return null!==t&&void 0!==t&&t.length?(0,W.jsx)("div",{className:de(null),style:{height:n,minHeight:n},children:(0,W.jsx)(te.V,{className:de("pdisk-bar"),severity:e.Severity,diskAllocatedPercent:e.AllocatedPercent,content:null===t||void 0===t?void 0:t.map(((e,t)=>(0,W.jsx)(me,{item:e,pDiskId:s,nodeId:i},t))),faded:!0})}):F("no-slots-data")}function me({item:e,pDiskId:t,nodeId:s}){return(0,W.jsx)("div",{className:de("slot-wrapper"),style:{flexGrow:Number(e.Total)||1},children:(()=>{if("vDisk"===e.SlotType){var i;const n=(0,w.f8)(null===(i=e.SlotData)||void 0===i?void 0:i.VDiskSlotId)&&(0,w.f8)(t)&&(0,w.f8)(s)?(0,b.yX)(e.SlotData.VDiskSlotId,t,s):void 0;return(0,W.jsx)(se.P,{popupContent:(0,W.jsx)(ae.E,{data:e.SlotData,withTitle:!0}),contentClassName:de("vdisk-popup"),placement:["right","top"],children:(0,W.jsx)(ne.E,{to:n,children:(0,W.jsx)(te.V,{className:de("slot"),severity:e.Severity,diskAllocatedPercent:e.UsagePercent,content:(0,W.jsx)(pe,{id:e.Id,title:e.Title,used:e.Used,total:e.Total})})})})}return function(e){return"log"===e.SlotType}(e)?(0,W.jsx)(se.P,{popupContent:(0,W.jsx)(he,{data:e.SlotData}),contentClassName:de("vdisk-popup"),placement:["right","top"],children:(0,W.jsx)(te.V,{className:de("slot"),severity:e.Severity,diskAllocatedPercent:e.UsagePercent,content:(0,W.jsx)(pe,{title:F("log"),used:e.Used,total:e.Total})})}):function(e){return"empty"===e.SlotType}(e)?(0,W.jsx)(se.P,{popupContent:(0,W.jsx)(ve,{data:e.SlotData}),contentClassName:de("vdisk-popup"),placement:["right","top"],children:(0,W.jsx)(te.V,{className:de("slot"),severity:e.Severity,empty:!0,content:(0,W.jsx)(pe,{title:F("empty-slot"),used:e.Total})})}):null})()})}function pe({id:e,title:t,used:s,total:i}){return(0,W.jsxs)("div",{className:de("slot-content"),children:[(0,W.jsxs)("span",{children:[(0,w.f8)(e)?(0,W.jsx)("span",{className:de("slot-id"),children:e}):null,t]}),(0,W.jsx)("span",{className:de("slot-size"),children:(()=>{const[e,t]=(0,re.vX)(s,i);return i?`${e} / ${t}`:e})()})]})}function he({data:e}){const{LogTotalSize:t,LogUsedSize:s,SystemSize:i}=e,n=[{label:F("label.log-size"),value:(0,W.jsx)(oe.O,{value:s,capacity:t,formatValues:re.vX})}];return(0,w.f8)(i)&&n.push({label:F("label.system-size"),value:(0,le.z3)({value:i})}),(0,W.jsx)(ie.z_,{title:F("log"),info:n})}function ve({data:e}){const{Size:t}=e,s=[{label:F("label.slot-size"),value:(0,le.z3)({value:t})}];return(0,W.jsx)(ie.z_,{title:F("empty-slot"),info:s})}const ge=(0,T.cn)("ydb-pdisk-page"),fe={diskDistribution:"diskDistribution",storage:"storage"},be=[{id:fe.diskDistribution,get title(){return F("disk-distribution")}},{id:fe.storage,get title(){return F("storage")}}],xe=c.z.nativeEnum(fe).catch(fe.diskDistribution);function ke(){const e=(0,E.YQ)(),t=(0,E.N4)(k._5),s=(0,y.c2)(),c=i.useRef(null),[{nodeId:S,pDiskId:D,activeTab:I}]=(0,d.useQueryParams)({activeTab:d.StringParam,nodeId:d.StringParam,pDiskId:d.StringParam}),T=(0,w.f8)(S)&&(0,w.f8)(D),z=xe.parse(I);i.useEffect((()=>{e((0,j.g)("pDisk",{nodeId:S,pDiskId:D}))}),[e,S,D]);const[A]=(0,E.Nt)(),_=T?{nodeId:S,pDiskId:D}:l.hT,M=C.useGetPdiskInfoQuery(_,{pollingInterval:A}),O=M.isFetching&&void 0===M.currentData,R=M.currentData,{NodeHost:L,NodeId:B,NodeType:V,NodeDC:$,Severity:U,DecommitStatus:G}=R||{},H=async e=>{if(T){const t=await window.api.pdisk[s?"restartPDisk":"restartPDiskOld"]({nodeId:S,pDiskId:D,force:e});if(!1===(null===t||void 0===t?void 0:t.result)){throw{statusText:t.error,retryPossible:t.forceRetryPossible}}}},J=async(e,t)=>{if(T){const s=await window.api.pdisk.changePDiskStatus({nodeId:S,pDiskId:D,force:t,decommissionStatus:e});if(!1===(null===s||void 0===s?void 0:s.result)){throw{statusText:s.error,retryPossible:s.forceRetryPossible}}}},q=()=>{T&&e(x.F.util.invalidateTags([{type:"PDiskData",id:(0,N.r$)(S,D)}]),"StorageData")};return(0,W.jsxs)("div",{className:ge(null),ref:c,children:[(()=>{const e=D?`${F("pdisk")} ${D}`:F("pdisk"),t=L||F("node");return(0,W.jsx)(r.mg,{titleTemplate:`%s - ${e} \u2014 ${t} \u2014 YDB Monitoring`,defaultTitle:`${e} \u2014 ${t} \u2014 YDB Monitoring`})})(),(()=>{const e=L?`${F("fqdn")}: ${L}`:void 0,t=B?`${F("node")}: ${B}`:void 0;return(0,W.jsx)(f.B,{loading:O,items:[e,t,V,$],className:ge("meta")})})(),(0,W.jsxs)("div",{className:ge("title"),children:[(0,W.jsx)(m.$,{entityName:F("pdisk"),status:(0,N.XY)(U),id:(0,N.r$)(S,D)}),(0,W.jsx)(ee,{decommission:G})]}),(0,W.jsxs)("div",{className:ge("controls"),children:[(0,W.jsxs)(u.B,{onConfirmAction:H,onConfirmActionSuccess:q,buttonDisabled:!T||!t,buttonView:"normal",dialogHeader:F("restart-pdisk-dialog-header"),dialogText:F("restart-pdisk-dialog-text"),retryButtonText:F("force-restart-pdisk-button"),withPopover:!0,popoverContent:F("restart-pdisk-not-allowed"),popoverDisabled:t,children:[(0,W.jsx)(o.I,{data:n.A}),F("restart-pdisk-button")]}),s?(0,W.jsx)(X,{decommission:G,onConfirmAction:J,onConfirmActionSuccess:q,buttonDisabled:!T||!t,popoverDisabled:t}):null]}),M.error?(0,W.jsx)(p.o,{error:M.error}):null,O?(0,W.jsx)(h.y,{className:ge("info"),rows:10}):(0,W.jsx)(g.Q,{pDisk:R,nodeId:S,className:ge("info")}),(0,W.jsx)("div",{className:ge("tabs"),children:(0,W.jsx)(a.t,{size:"l",items:be,activeTab:z,wrapTo:({id:e},t)=>{const s=T?(0,b.Ck)(D,S,{activeTab:e}):void 0;return(0,W.jsx)(v.E,{to:s,children:t},e)}})}),(()=>{switch(z){case"diskDistribution":return R?(0,W.jsx)("div",{className:ge("disk-distribution"),children:(0,W.jsx)(ue,{data:R})}):null;case"storage":return T?(0,W.jsx)(P.z,{nodeId:S,pDiskId:D,parentRef:c,viewContext:{nodeId:null===S||void 0===S?void 0:S.toString(),pDiskId:null===D||void 0===D?void 0:D.toString()}}):null;default:return null}})()]})}},89954:(e,t,s)=>{s.d(t,{O:()=>D});var i=s(59284),n=s(45720),o=s(16929),a=s(71153),l=s(18677),r=s(84476),d=s(33705),c=s(67884),u=s(99991),m=s(77506),p=s(48372);const h=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),v=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),g=(0,p.g4)("ydb-shorty-string",{ru:v,en:h});var f=s(60712);const b=(0,m.cn)("kv-shorty-string");function x({value:e="",limit:t=200,strict:s=!1,displayLength:n=!0,render:o=e=>e,onToggle:a,expandLabel:l=g("default_expand_label"),collapseLabel:r=g("default_collapse_label")}){const[d,u]=i.useState(!1),m=(d?r:l)+(n&&!d?g("chars_count",{count:e.length}):""),p=e.length>t+(s?0:m.length),h=d||!p?e:e.slice(0,t-4)+"\xa0...";return(0,f.jsxs)("div",{className:b(),children:[o(h),p?(0,f.jsx)(c.N,{className:b("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),u((e=>!e)),null===a||void 0===a||a()},children:m}):null]})}var k=s(41650);const y=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function j(e){return function(e){return!!e&&void 0!==y[e]}(e)?y[e]:"S_INFO"}const N=(0,m.cn)("kv-result-issues"),S=(0,m.cn)("kv-issues"),w=(0,m.cn)("kv-issue");function D({data:e,hideSeverity:t}){const[s,n]=i.useState(!1),o="string"===typeof e||null===e||void 0===e?void 0:e.issues,a=Array.isArray(o)&&o.length>0;return(0,f.jsxs)("div",{className:N(),children:[(0,f.jsxs)("div",{className:N("error-message"),children:[(()=>{let s;if("string"===typeof e)s=e;else{var n,o;const a=j(null===e||void 0===e||null===(n=e.error)||void 0===n?void 0:n.severity);s=(0,f.jsxs)(i.Fragment,{children:[t?null:(0,f.jsxs)(i.Fragment,{children:[(0,f.jsx)(A,{severity:a})," "]}),(0,f.jsx)("span",{className:N("error-message-text"),children:null===e||void 0===e||null===(o=e.error)||void 0===o?void 0:o.message})]})}return s})(),a&&(0,f.jsx)(r.$,{view:"normal",onClick:()=>n(!s),children:s?"Hide details":"Show details"})]}),a&&s&&(0,f.jsx)(I,{hideSeverity:t,issues:o})]})}function I({issues:e,hideSeverity:t}){const s=null===e||void 0===e?void 0:e.reduce(((e,t)=>{var s;const i=null!==(s=t.severity)&&void 0!==s?s:10;return Math.min(e,i)}),10);return(0,f.jsx)("div",{className:S(null),children:null===e||void 0===e?void 0:e.map(((e,i)=>(0,f.jsx)(C,{hideSeverity:t,issue:e,expanded:e===s},i)))})}function C({issue:e,hideSeverity:t,level:s=0}){const[n,o]=i.useState(!0),a=j(e.severity),l=e.issues,c=Array.isArray(l)&&l.length>0,u=n?"bottom":"right";return(0,f.jsxs)("div",{className:w({leaf:!c,"has-issues":c}),children:[(0,f.jsxs)("div",{className:w("line"),children:[c&&(0,f.jsx)(r.$,{view:"flat-secondary",onClick:()=>o(!n),className:w("arrow-toggle"),children:(0,f.jsx)(d.I,{direction:u,size:16})}),t?null:(0,f.jsx)(A,{severity:a}),(0,f.jsx)(T,{issue:e}),e.issue_code?(0,f.jsxs)("span",{className:w("code"),children:["Code: ",e.issue_code]}):null]}),c&&n&&(0,f.jsx)("div",{className:w("issues"),children:(0,f.jsx)(E,{issues:l,level:s+1,expanded:n})})]})}function T({issue:e}){var t;const s=function(e){const{position:t}=e;if("object"!==typeof t||null===t||!(0,k.kf)(t.row))return"";const{row:s,column:i}=t;return(0,k.kf)(i)?`${s}:${i}`:`line ${s}`}(e),i=window.ydbEditor,n=()=>(0,f.jsxs)("span",{className:w("message"),children:[s&&(0,f.jsx)("span",{className:w("place-text"),title:"Position",children:s}),(0,f.jsx)("div",{className:w("message-text"),children:(0,f.jsx)(x,{value:e.message,expandLabel:"Show full message"})})]}),{row:o,column:a}=null!==(t=e.position)&&void 0!==t?t:{};if(!((0,k.kf)(o)&&i))return n();return(0,f.jsx)(c.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:o,column:null!==a&&void 0!==a?a:0};i.setPosition(e),i.revealPositionInCenterIfOutsideViewport(e),i.focus()},view:"primary",children:n()})}function E(e){const{issues:t,level:s,expanded:i}=e;return(0,f.jsx)("div",{className:w("list"),children:t.map(((e,t)=>(0,f.jsx)(C,{issue:e,level:s,expanded:i},t)))})}const P={S_INFO:n.A,S_WARNING:o.A,S_ERROR:a.A,S_FATAL:l.A},z=(0,m.cn)("yql-issue-severity");function A({severity:e}){const t=e.slice(2).toLowerCase();return(0,f.jsxs)("span",{className:z({severity:t}),children:[(0,f.jsx)(u.I,{className:z("icon"),data:P[e]}),(0,f.jsx)("span",{className:z("title"),children:t})]})}},76938:(e,t,s)=>{s.d(t,{A:()=>n});var i=s(59284);const n=e=>i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),i.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 1 1-6.445 7.348.75.75 0 1 1 1.487-.194A5.001 5.001 0 1 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 0 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5",clipRule:"evenodd"}))},18677:(e,t,s)=>{s.d(t,{A:()=>n});var i=s(59284);const n=e=>i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),i.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},74321:(e,t,s)=>{s.d(t,{S:()=>d});var i=s(59284),n=s(64222),o=s(46898);function a(e){return i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),i.createElement("path",{d:"M4 7h9v3H4z"}))}function l(e){return i.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),i.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const r=(0,s(69220).om)("checkbox"),d=i.forwardRef((function(e,t){const{size:s="m",indeterminate:d,disabled:c=!1,content:u,children:m,title:p,style:h,className:v,qa:g}=e,{checked:f,inputProps:b}=(0,n.v)(e),x=u||m,k=i.createElement("span",{className:r("indicator")},i.createElement("span",{className:r("icon"),"aria-hidden":!0},d?i.createElement(a,{className:r("icon-svg",{type:"dash"})}):i.createElement(l,{className:r("icon-svg",{type:"tick"})})),i.createElement("input",Object.assign({},b,{className:r("control")})),i.createElement("span",{className:r("outline")}));return i.createElement(o.m,{ref:t,title:p,style:h,size:s,disabled:c,className:r({size:s,disabled:c,indeterminate:d,checked:f},v),qa:g,control:k},x)}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/68527.1f687bcf.chunk.js b/ydb/core/viewer/monitoring/static/js/68527.1f687bcf.chunk.js new file mode 100644 index 000000000000..29feb385a83e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/68527.1f687bcf.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[68527],{14352:a=>{function e(a){a.languages.log={string:{pattern:/"(?:[^"\\\r\n]|\\.)*"|'(?![st] | \w)(?:[^'\\\r\n]|\\.)*'/,greedy:!0},exception:{pattern:/(^|[^\w.])[a-z][\w.]*(?:Error|Exception):.*(?:(?:\r\n?|\n)[ \t]*(?:at[ \t].+|\.{3}.*|Caused by:.*))+(?:(?:\r\n?|\n)[ \t]*\.\.\. .*)?/,lookbehind:!0,greedy:!0,alias:["javastacktrace","language-javastacktrace"],inside:a.languages.javastacktrace||{keyword:/\bat\b/,function:/[a-z_][\w$]*(?=\()/,punctuation:/[.:()]/}},level:[{pattern:/\b(?:ALERT|CRIT|CRITICAL|EMERG|EMERGENCY|ERR|ERROR|FAILURE|FATAL|SEVERE)\b/,alias:["error","important"]},{pattern:/\b(?:WARN|WARNING|WRN)\b/,alias:["warning","important"]},{pattern:/\b(?:DISPLAY|INF|INFO|NOTICE|STATUS)\b/,alias:["info","keyword"]},{pattern:/\b(?:DBG|DEBUG|FINE)\b/,alias:["debug","keyword"]},{pattern:/\b(?:FINER|FINEST|TRACE|TRC|VERBOSE|VRB)\b/,alias:["trace","comment"]}],property:{pattern:/((?:^|[\]|])[ \t]*)[a-z_](?:[\w-]|\b\/\b)*(?:[. ]\(?\w(?:[\w-]|\b\/\b)*\)?)*:(?=\s)/im,lookbehind:!0},separator:{pattern:/(^|[^-+])-{3,}|={3,}|\*{3,}|- - /m,lookbehind:!0,alias:"comment"},url:/\b(?:file|ftp|https?):\/\/[^\s|,;'"]*[^\s|,;'">.]/,email:{pattern:/(^|\s)[-\w+.]+@[a-z][a-z0-9-]*(?:\.[a-z][a-z0-9-]*)+(?=\s)/,lookbehind:!0,alias:"url"},"ip-address":{pattern:/\b(?:\d{1,3}(?:\.\d{1,3}){3})\b/,alias:"constant"},"mac-address":{pattern:/\b[a-f0-9]{2}(?::[a-f0-9]{2}){5}\b/i,alias:"constant"},domain:{pattern:/(^|\s)[a-z][a-z0-9-]*(?:\.[a-z][a-z0-9-]*)*\.[a-z][a-z0-9-]+(?=\s)/,lookbehind:!0,alias:"constant"},uuid:{pattern:/\b[0-9a-f]{8}-[0-9a-f]{4}-[0-9a-f]{4}-[0-9a-f]{4}-[0-9a-f]{12}\b/i,alias:"constant"},hash:{pattern:/\b(?:[a-f0-9]{32}){1,2}\b/i,alias:"constant"},"file-path":{pattern:/\b[a-z]:[\\/][^\s|,;:(){}\[\]"']+|(^|[\s:\[\](>|])\.{0,2}\/\w[^\s|,;:(){}\[\]"']*/i,lookbehind:!0,greedy:!0,alias:"string"},date:{pattern:RegExp(/\b\d{4}[-/]\d{2}[-/]\d{2}(?:T(?=\d{1,2}:)|(?=\s\d{1,2}:))/.source+"|"+/\b\d{1,4}[-/ ](?:\d{1,2}|Apr|Aug|Dec|Feb|Jan|Jul|Jun|Mar|May|Nov|Oct|Sep)[-/ ]\d{2,4}T?\b/.source+"|"+/\b(?:(?:Fri|Mon|Sat|Sun|Thu|Tue|Wed)(?:\s{1,2}(?:Apr|Aug|Dec|Feb|Jan|Jul|Jun|Mar|May|Nov|Oct|Sep))?|Apr|Aug|Dec|Feb|Jan|Jul|Jun|Mar|May|Nov|Oct|Sep)\s{1,2}\d{1,2}\b/.source,"i"),alias:"number"},time:{pattern:/\b\d{1,2}:\d{1,2}:\d{1,2}(?:[.,:]\d+)?(?:\s?[+-]\d{2}:?\d{2}|Z)?\b/,alias:"number"},boolean:/\b(?:false|null|true)\b/i,number:{pattern:/(^|[^.\w])(?:0x[a-f0-9]+|0o[0-7]+|0b[01]+|v?\d[\da-f]*(?:\.\d+)*(?:e[+-]?\d+)?[a-z]{0,3}\b)\b(?!\.\w)/i,lookbehind:!0},operator:/[;:?<=>~/@!$%&+\-|^(){}*#]/,punctuation:/[\[\].,]/}}a.exports=e,e.displayName="log",e.aliases=[]},68527:(a,e,t)=>{t.d(e,{default:()=>r});var n=t(14352);const r=t.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6879.2965a366.chunk.js b/ydb/core/viewer/monitoring/static/js/6879.2965a366.chunk.js deleted file mode 100644 index 3c6aa6b511eb..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6879.2965a366.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6879],{76879:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"zh",weekdays:"\u661f\u671f\u65e5_\u661f\u671f\u4e00_\u661f\u671f\u4e8c_\u661f\u671f\u4e09_\u661f\u671f\u56db_\u661f\u671f\u4e94_\u661f\u671f\u516d".split("_"),weekdaysShort:"\u5468\u65e5_\u5468\u4e00_\u5468\u4e8c_\u5468\u4e09_\u5468\u56db_\u5468\u4e94_\u5468\u516d".split("_"),weekdaysMin:"\u65e5_\u4e00_\u4e8c_\u4e09_\u56db_\u4e94_\u516d".split("_"),months:"\u4e00\u6708_\u4e8c\u6708_\u4e09\u6708_\u56db\u6708_\u4e94\u6708_\u516d\u6708_\u4e03\u6708_\u516b\u6708_\u4e5d\u6708_\u5341\u6708_\u5341\u4e00\u6708_\u5341\u4e8c\u6708".split("_"),monthsShort:"1\u6708_2\u6708_3\u6708_4\u6708_5\u6708_6\u6708_7\u6708_8\u6708_9\u6708_10\u6708_11\u6708_12\u6708".split("_"),ordinal:function(_,e){return"W"===e?_+"\u5468":_+"\u65e5"},weekStart:1,yearStart:4,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY/MM/DD",LL:"YYYY\u5e74M\u6708D\u65e5",LLL:"YYYY\u5e74M\u6708D\u65e5Ah\u70b9mm\u5206",LLLL:"YYYY\u5e74M\u6708D\u65e5ddddAh\u70b9mm\u5206",l:"YYYY/M/D",ll:"YYYY\u5e74M\u6708D\u65e5",lll:"YYYY\u5e74M\u6708D\u65e5 HH:mm",llll:"YYYY\u5e74M\u6708D\u65e5dddd HH:mm"},relativeTime:{future:"%s\u540e",past:"%s\u524d",s:"\u51e0\u79d2",m:"1 \u5206\u949f",mm:"%d \u5206\u949f",h:"1 \u5c0f\u65f6",hh:"%d \u5c0f\u65f6",d:"1 \u5929",dd:"%d \u5929",M:"1 \u4e2a\u6708",MM:"%d \u4e2a\u6708",y:"1 \u5e74",yy:"%d \u5e74"},meridiem:function(_,e){var t=100*_+e;return t<600?"\u51cc\u6668":t<900?"\u65e9\u4e0a":t<1100?"\u4e0a\u5348":t<1300?"\u4e2d\u5348":t<1800?"\u4e0b\u5348":"\u665a\u4e0a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/68818.0e24392e.chunk.js b/ydb/core/viewer/monitoring/static/js/68818.0e24392e.chunk.js new file mode 100644 index 000000000000..a96eabc555c2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/68818.0e24392e.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[68818],{26467:t=>{function n(t){!function(t){var n={pattern:/(^[ \t]*)\[(?!\[)(?:(["'$`])(?:(?!\2)[^\\]|\\.)*\2|\[(?:[^\[\]\\]|\\.)*\]|[^\[\]\\"'$`]|\\.)*\]/m,lookbehind:!0,inside:{quoted:{pattern:/([$`])(?:(?!\1)[^\\]|\\.)*\1/,inside:{punctuation:/^[$`]|[$`]$/}},interpreted:{pattern:/'(?:[^'\\]|\\.)*'/,inside:{punctuation:/^'|'$/}},string:/"(?:[^"\\]|\\.)*"/,variable:/\w+(?==)/,punctuation:/^\[|\]$|,/,operator:/=/,"attr-value":/(?!^\s+$).+/}},e=t.languages.asciidoc={"comment-block":{pattern:/^(\/{4,})(?:\r?\n|\r)(?:[\s\S]*(?:\r?\n|\r))??\1/m,alias:"comment"},table:{pattern:/^\|={3,}(?:(?:\r?\n|\r(?!\n)).*)*?(?:\r?\n|\r)\|={3,}$/m,inside:{specifiers:{pattern:/(?:(?:(?:\d+(?:\.\d+)?|\.\d+)[+*](?:[<^>](?:\.[<^>])?|\.[<^>])?|[<^>](?:\.[<^>])?|\.[<^>])[a-z]*|[a-z]+)(?=\|)/,alias:"attr-value"},punctuation:{pattern:/(^|[^\\])[|!]=*/,lookbehind:!0}}},"passthrough-block":{pattern:/^(\+{4,})(?:\r?\n|\r)(?:[\s\S]*(?:\r?\n|\r))??\1$/m,inside:{punctuation:/^\++|\++$/}},"literal-block":{pattern:/^(-{4,}|\.{4,})(?:\r?\n|\r)(?:[\s\S]*(?:\r?\n|\r))??\1$/m,inside:{punctuation:/^(?:-+|\.+)|(?:-+|\.+)$/}},"other-block":{pattern:/^(--|\*{4,}|_{4,}|={4,})(?:\r?\n|\r)(?:[\s\S]*(?:\r?\n|\r))??\1$/m,inside:{punctuation:/^(?:-+|\*+|_+|=+)|(?:-+|\*+|_+|=+)$/}},"list-punctuation":{pattern:/(^[ \t]*)(?:-|\*{1,5}|\.{1,5}|(?:[a-z]|\d+)\.|[xvi]+\))(?= )/im,lookbehind:!0,alias:"punctuation"},"list-label":{pattern:/(^[ \t]*)[a-z\d].+(?::{2,4}|;;)(?=\s)/im,lookbehind:!0,alias:"symbol"},"indented-block":{pattern:/((\r?\n|\r)\2)([ \t]+)\S.*(?:(?:\r?\n|\r)\3.+)*(?=\2{2}|$)/,lookbehind:!0},comment:/^\/\/.*/m,title:{pattern:/^.+(?:\r?\n|\r)(?:={3,}|-{3,}|~{3,}|\^{3,}|\+{3,})$|^={1,5} .+|^\.(?![\s.]).*/m,alias:"important",inside:{punctuation:/^(?:\.|=+)|(?:=+|-+|~+|\^+|\++)$/}},"attribute-entry":{pattern:/^:[^:\r\n]+:(?: .*?(?: \+(?:\r?\n|\r).*?)*)?$/m,alias:"tag"},attributes:n,hr:{pattern:/^'{3,}$/m,alias:"punctuation"},"page-break":{pattern:/^<{3,}$/m,alias:"punctuation"},admonition:{pattern:/^(?:CAUTION|IMPORTANT|NOTE|TIP|WARNING):/m,alias:"keyword"},callout:[{pattern:/(^[ \t]*)/m,lookbehind:!0,alias:"symbol"},{pattern:/<\d+>/,alias:"symbol"}],macro:{pattern:/\b[a-z\d][a-z\d-]*::?(?:[^\s\[\]]*\[(?:[^\]\\"']|(["'])(?:(?!\1)[^\\]|\\.)*\1|\\.)*\])/,inside:{function:/^[a-z\d-]+(?=:)/,punctuation:/^::?/,attributes:{pattern:/(?:\[(?:[^\]\\"']|(["'])(?:(?!\1)[^\\]|\\.)*\1|\\.)*\])/,inside:n.inside}}},inline:{pattern:/(^|[^\\])(?:(?:\B\[(?:[^\]\\"']|(["'])(?:(?!\2)[^\\]|\\.)*\2|\\.)*\])?(?:\b_(?!\s)(?: _|[^_\\\r\n]|\\.)+(?:(?:\r?\n|\r)(?: _|[^_\\\r\n]|\\.)+)*_\b|\B``(?!\s).+?(?:(?:\r?\n|\r).+?)*''\B|\B`(?!\s)(?:[^`'\s]|\s+\S)+['`]\B|\B(['*+#])(?!\s)(?: \3|(?!\3)[^\\\r\n]|\\.)+(?:(?:\r?\n|\r)(?: \3|(?!\3)[^\\\r\n]|\\.)+)*\3\B)|(?:\[(?:[^\]\\"']|(["'])(?:(?!\4)[^\\]|\\.)*\4|\\.)*\])?(?:(__|\*\*|\+\+\+?|##|\$\$|[~^]).+?(?:(?:\r?\n|\r).+?)*\5|\{[^}\r\n]+\}|\[\[\[?.+?(?:(?:\r?\n|\r).+?)*\]?\]\]|<<.+?(?:(?:\r?\n|\r).+?)*>>|\(\(\(?.+?(?:(?:\r?\n|\r).+?)*\)?\)\)))/m,lookbehind:!0,inside:{attributes:n,url:{pattern:/^(?:\[\[\[?.+?\]?\]\]|<<.+?>>)$/,inside:{punctuation:/^(?:\[\[\[?|<<)|(?:\]\]\]?|>>)$/}},"attribute-ref":{pattern:/^\{.+\}$/,inside:{variable:{pattern:/(^\{)[a-z\d,+_-]+/,lookbehind:!0},operator:/^[=?!#%@$]|!(?=[:}])/,punctuation:/^\{|\}$|::?/}},italic:{pattern:/^(['_])[\s\S]+\1$/,inside:{punctuation:/^(?:''?|__?)|(?:''?|__?)$/}},bold:{pattern:/^\*[\s\S]+\*$/,inside:{punctuation:/^\*\*?|\*\*?$/}},punctuation:/^(?:``?|\+{1,3}|##?|\$\$|[~^]|\(\(\(?)|(?:''?|\+{1,3}|##?|\$\$|[~^`]|\)?\)\))$/}},replacement:{pattern:/\((?:C|R|TM)\)/,alias:"builtin"},entity:/&#?[\da-z]{1,8};/i,"line-continuation":{pattern:/(^| )\+$/m,lookbehind:!0,alias:"punctuation"}};function i(t){for(var n={},i=0,a=(t=t.split(" ")).length;i{e.d(n,{default:()=>a});var i=e(26467);const a=e.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/68821.a96b8277.chunk.js b/ydb/core/viewer/monitoring/static/js/68821.a96b8277.chunk.js new file mode 100644 index 000000000000..5aa658fde495 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/68821.a96b8277.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 68821.a96b8277.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[68821],{68821:(e,t,n)=>{n.r(t),n.d(t,{CompletionAdapter:()=>Ht,DefinitionAdapter:()=>Zt,DiagnosticsAdapter:()=>Ot,DocumentColorAdapter:()=>ln,DocumentFormattingEditProvider:()=>un,DocumentHighlightAdapter:()=>Jt,DocumentLinkAdapter:()=>sn,DocumentRangeFormattingEditProvider:()=>cn,DocumentSymbolAdapter:()=>rn,FoldingRangeAdapter:()=>gn,HoverAdapter:()=>qt,ReferenceAdapter:()=>tn,RenameAdapter:()=>nn,SelectionRangeAdapter:()=>fn,WorkerManager:()=>Nt,fromPosition:()=>Kt,fromRange:()=>Xt,setupMode:()=>pn,setupMode1:()=>hn,toRange:()=>zt,toTextEdit:()=>Bt});var r,i,o=n(80781),a=Object.defineProperty,s=Object.getOwnPropertyDescriptor,u=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,d=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of u(t))c.call(e,i)||i===n||a(e,i,{get:()=>t[i],enumerable:!(r=s(t,i))||r.enumerable});return e},l={};d(l,r=o,"default"),i&&d(i,r,"default");var g,f,m,h,p,v,b,_,k,w,y,x,I,E,S,A,C,R,L,T,M,P,D,F,j,N,U,V,O,W,H,K,X,z,$,B,q,Q,G,J,Y,Z,ee,te,ne,re,ie,oe,ae,se,ue,ce,de,le,ge,fe,me,he,pe,ve,be,_e,ke,we,ye,xe,Ie,Ee,Se,Ae,Ce,Re,Le,Te,Me,Pe,De,Fe,je,Ne,Ue,Ve,Oe,We,He,Ke,Xe,ze,$e,Be,qe,Qe,Ge,Je,Ye,Ze,et,tt,nt,rt,it,ot,at,st,ut,ct,dt,lt,gt,ft,mt,ht,pt,vt,bt,_t,kt,wt,yt,xt,It,Et,St,At,Ct,Rt,Lt,Tt,Mt,Pt,Dt,Ft,jt,Nt=class{constructor(e){this._defaults=e,this._worker=null,this._client=null,this._idleCheckInterval=window.setInterval((()=>this._checkIfIdle()),3e4),this._lastUsedTime=0,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker()))}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}dispose(){clearInterval(this._idleCheckInterval),this._configChangeListener.dispose(),this._stopWorker()}_checkIfIdle(){if(!this._worker)return;Date.now()-this._lastUsedTime>12e4&&this._stopWorker()}_getClient(){return this._lastUsedTime=Date.now(),this._client||(this._worker=l.editor.createWebWorker({moduleId:"vs/language/html/htmlWorker",createData:{languageSettings:this._defaults.options,languageId:this._defaults.languageId},label:this._defaults.languageId}),this._client=this._worker.getProxy()),this._client}getLanguageServiceWorker(...e){let t;return this._getClient().then((e=>{t=e})).then((t=>{if(this._worker)return this._worker.withSyncedResources(e)})).then((e=>t))}};(g||(g={})).is=function(e){return"string"===typeof e},(f||(f={})).is=function(e){return"string"===typeof e},(h=m||(m={})).MIN_VALUE=-2147483648,h.MAX_VALUE=2147483647,h.is=function(e){return"number"===typeof e&&h.MIN_VALUE<=e&&e<=h.MAX_VALUE},(v=p||(p={})).MIN_VALUE=0,v.MAX_VALUE=2147483647,v.is=function(e){return"number"===typeof e&&v.MIN_VALUE<=e&&e<=v.MAX_VALUE},(_=b||(b={})).create=function(e,t){return e===Number.MAX_VALUE&&(e=p.MAX_VALUE),t===Number.MAX_VALUE&&(t=p.MAX_VALUE),{line:e,character:t}},_.is=function(e){let t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.line)&&Ut.uinteger(t.character)},(w=k||(k={})).create=function(e,t,n,r){if(Ut.uinteger(e)&&Ut.uinteger(t)&&Ut.uinteger(n)&&Ut.uinteger(r))return{start:b.create(e,t),end:b.create(n,r)};if(b.is(e)&&b.is(t))return{start:e,end:t};throw new Error(`Range#create called with invalid arguments[${e}, ${t}, ${n}, ${r}]`)},w.is=function(e){let t=e;return Ut.objectLiteral(t)&&b.is(t.start)&&b.is(t.end)},(x=y||(y={})).create=function(e,t){return{uri:e,range:t}},x.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(Ut.string(t.uri)||Ut.undefined(t.uri))},(E=I||(I={})).create=function(e,t,n,r){return{targetUri:e,targetRange:t,targetSelectionRange:n,originSelectionRange:r}},E.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.targetRange)&&Ut.string(t.targetUri)&&k.is(t.targetSelectionRange)&&(k.is(t.originSelectionRange)||Ut.undefined(t.originSelectionRange))},(A=S||(S={})).create=function(e,t,n,r){return{red:e,green:t,blue:n,alpha:r}},A.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.numberRange(t.red,0,1)&&Ut.numberRange(t.green,0,1)&&Ut.numberRange(t.blue,0,1)&&Ut.numberRange(t.alpha,0,1)},(R=C||(C={})).create=function(e,t){return{range:e,color:t}},R.is=function(e){const t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&S.is(t.color)},(T=L||(L={})).create=function(e,t,n){return{label:e,textEdit:t,additionalTextEdits:n}},T.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.undefined(t.textEdit)||B.is(t))&&(Ut.undefined(t.additionalTextEdits)||Ut.typedArray(t.additionalTextEdits,B.is))},(P=M||(M={})).Comment="comment",P.Imports="imports",P.Region="region",(F=D||(D={})).create=function(e,t,n,r,i,o){const a={startLine:e,endLine:t};return Ut.defined(n)&&(a.startCharacter=n),Ut.defined(r)&&(a.endCharacter=r),Ut.defined(i)&&(a.kind=i),Ut.defined(o)&&(a.collapsedText=o),a},F.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.startLine)&&Ut.uinteger(t.startLine)&&(Ut.undefined(t.startCharacter)||Ut.uinteger(t.startCharacter))&&(Ut.undefined(t.endCharacter)||Ut.uinteger(t.endCharacter))&&(Ut.undefined(t.kind)||Ut.string(t.kind))},(N=j||(j={})).create=function(e,t){return{location:e,message:t}},N.is=function(e){let t=e;return Ut.defined(t)&&y.is(t.location)&&Ut.string(t.message)},(V=U||(U={})).Error=1,V.Warning=2,V.Information=3,V.Hint=4,(W=O||(O={})).Unnecessary=1,W.Deprecated=2,(H||(H={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.href)},(X=K||(K={})).create=function(e,t,n,r,i,o){let a={range:e,message:t};return Ut.defined(n)&&(a.severity=n),Ut.defined(r)&&(a.code=r),Ut.defined(i)&&(a.source=i),Ut.defined(o)&&(a.relatedInformation=o),a},X.is=function(e){var t;let n=e;return Ut.defined(n)&&k.is(n.range)&&Ut.string(n.message)&&(Ut.number(n.severity)||Ut.undefined(n.severity))&&(Ut.integer(n.code)||Ut.string(n.code)||Ut.undefined(n.code))&&(Ut.undefined(n.codeDescription)||Ut.string(null===(t=n.codeDescription)||void 0===t?void 0:t.href))&&(Ut.string(n.source)||Ut.undefined(n.source))&&(Ut.undefined(n.relatedInformation)||Ut.typedArray(n.relatedInformation,j.is))},($=z||(z={})).create=function(e,t,...n){let r={title:e,command:t};return Ut.defined(n)&&n.length>0&&(r.arguments=n),r},$.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.title)&&Ut.string(t.command)},(q=B||(B={})).replace=function(e,t){return{range:e,newText:t}},q.insert=function(e,t){return{range:{start:e,end:e},newText:t}},q.del=function(e){return{range:e,newText:""}},q.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.newText)&&k.is(t.range)},(G=Q||(Q={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},G.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(Ut.string(t.description)||void 0===t.description)},(J||(J={})).is=function(e){const t=e;return Ut.string(t)},(Z=Y||(Y={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},Z.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},Z.del=function(e,t){return{range:e,newText:"",annotationId:t}},Z.is=function(e){const t=e;return B.is(t)&&(Q.is(t.annotationId)||J.is(t.annotationId))},(te=ee||(ee={})).create=function(e,t){return{textDocument:e,edits:t}},te.is=function(e){let t=e;return Ut.defined(t)&&fe.is(t.textDocument)&&Array.isArray(t.edits)},(re=ne||(ne={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},re.is=function(e){let t=e;return t&&"create"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(oe=ie||(ie={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},oe.is=function(e){let t=e;return t&&"rename"===t.kind&&Ut.string(t.oldUri)&&Ut.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(se=ae||(ae={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},se.is=function(e){let t=e;return t&&"delete"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||Ut.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||Ut.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(ue||(ue={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>Ut.string(e.kind)?ne.is(e)||ie.is(e)||ae.is(e):ee.is(e))))},(de=ce||(ce={})).create=function(e){return{uri:e}},de.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)},(ge=le||(le={})).create=function(e,t){return{uri:e,version:t}},ge.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.integer(t.version)},(me=fe||(fe={})).create=function(e,t){return{uri:e,version:t}},me.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&(null===t.version||Ut.integer(t.version))},(pe=he||(he={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},pe.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.string(t.languageId)&&Ut.integer(t.version)&&Ut.string(t.text)},(be=ve||(ve={})).PlainText="plaintext",be.Markdown="markdown",be.is=function(e){const t=e;return t===be.PlainText||t===be.Markdown},(_e||(_e={})).is=function(e){const t=e;return Ut.objectLiteral(e)&&ve.is(t.kind)&&Ut.string(t.value)},(we=ke||(ke={})).Text=1,we.Method=2,we.Function=3,we.Constructor=4,we.Field=5,we.Variable=6,we.Class=7,we.Interface=8,we.Module=9,we.Property=10,we.Unit=11,we.Value=12,we.Enum=13,we.Keyword=14,we.Snippet=15,we.Color=16,we.File=17,we.Reference=18,we.Folder=19,we.EnumMember=20,we.Constant=21,we.Struct=22,we.Event=23,we.Operator=24,we.TypeParameter=25,(xe=ye||(ye={})).PlainText=1,xe.Snippet=2,(Ie||(Ie={})).Deprecated=1,(Se=Ee||(Ee={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},Se.is=function(e){const t=e;return t&&Ut.string(t.newText)&&k.is(t.insert)&&k.is(t.replace)},(Ce=Ae||(Ae={})).asIs=1,Ce.adjustIndentation=2,(Re||(Re={})).is=function(e){const t=e;return t&&(Ut.string(t.detail)||void 0===t.detail)&&(Ut.string(t.description)||void 0===t.description)},(Le||(Le={})).create=function(e){return{label:e}},(Te||(Te={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(Pe=Me||(Me={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},Pe.is=function(e){const t=e;return Ut.string(t)||Ut.objectLiteral(t)&&Ut.string(t.language)&&Ut.string(t.value)},(De||(De={})).is=function(e){let t=e;return!!t&&Ut.objectLiteral(t)&&(_e.is(t.contents)||Me.is(t.contents)||Ut.typedArray(t.contents,Me.is))&&(void 0===e.range||k.is(e.range))},(Fe||(Fe={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(je||(je={})).create=function(e,t,...n){let r={label:e};return Ut.defined(t)&&(r.documentation=t),Ut.defined(n)?r.parameters=n:r.parameters=[],r},(Ue=Ne||(Ne={})).Text=1,Ue.Read=2,Ue.Write=3,(Ve||(Ve={})).create=function(e,t){let n={range:e};return Ut.number(t)&&(n.kind=t),n},(We=Oe||(Oe={})).File=1,We.Module=2,We.Namespace=3,We.Package=4,We.Class=5,We.Method=6,We.Property=7,We.Field=8,We.Constructor=9,We.Enum=10,We.Interface=11,We.Function=12,We.Variable=13,We.Constant=14,We.String=15,We.Number=16,We.Boolean=17,We.Array=18,We.Object=19,We.Key=20,We.Null=21,We.EnumMember=22,We.Struct=23,We.Event=24,We.Operator=25,We.TypeParameter=26,(He||(He={})).Deprecated=1,(Ke||(Ke={})).create=function(e,t,n,r,i){let o={name:e,kind:t,location:{uri:r,range:n}};return i&&(o.containerName=i),o},(Xe||(Xe={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},($e=ze||(ze={})).create=function(e,t,n,r,i,o){let a={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==o&&(a.children=o),a},$e.is=function(e){let t=e;return t&&Ut.string(t.name)&&Ut.number(t.kind)&&k.is(t.range)&&k.is(t.selectionRange)&&(void 0===t.detail||Ut.string(t.detail))&&(void 0===t.deprecated||Ut.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},(qe=Be||(Be={})).Empty="",qe.QuickFix="quickfix",qe.Refactor="refactor",qe.RefactorExtract="refactor.extract",qe.RefactorInline="refactor.inline",qe.RefactorRewrite="refactor.rewrite",qe.Source="source",qe.SourceOrganizeImports="source.organizeImports",qe.SourceFixAll="source.fixAll",(Ge=Qe||(Qe={})).Invoked=1,Ge.Automatic=2,(Ye=Je||(Je={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},Ye.is=function(e){let t=e;return Ut.defined(t)&&Ut.typedArray(t.diagnostics,K.is)&&(void 0===t.only||Ut.typedArray(t.only,Ut.string))&&(void 0===t.triggerKind||t.triggerKind===Qe.Invoked||t.triggerKind===Qe.Automatic)},(et=Ze||(Ze={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):z.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},et.is=function(e){let t=e;return t&&Ut.string(t.title)&&(void 0===t.diagnostics||Ut.typedArray(t.diagnostics,K.is))&&(void 0===t.kind||Ut.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||z.is(t.command))&&(void 0===t.isPreferred||Ut.boolean(t.isPreferred))&&(void 0===t.edit||ue.is(t.edit))},(nt=tt||(tt={})).create=function(e,t){let n={range:e};return Ut.defined(t)&&(n.data=t),n},nt.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.command)||z.is(t.command))},(it=rt||(rt={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},it.is=function(e){let t=e;return Ut.defined(t)&&Ut.uinteger(t.tabSize)&&Ut.boolean(t.insertSpaces)},(at=ot||(ot={})).create=function(e,t,n){return{range:e,target:t,data:n}},at.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.target)||Ut.string(t.target))},(ut=st||(st={})).create=function(e,t){return{range:e,parent:t}},ut.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(void 0===t.parent||ut.is(t.parent))},(dt=ct||(ct={})).namespace="namespace",dt.type="type",dt.class="class",dt.enum="enum",dt.interface="interface",dt.struct="struct",dt.typeParameter="typeParameter",dt.parameter="parameter",dt.variable="variable",dt.property="property",dt.enumMember="enumMember",dt.event="event",dt.function="function",dt.method="method",dt.macro="macro",dt.keyword="keyword",dt.modifier="modifier",dt.comment="comment",dt.string="string",dt.number="number",dt.regexp="regexp",dt.operator="operator",dt.decorator="decorator",(gt=lt||(lt={})).declaration="declaration",gt.definition="definition",gt.readonly="readonly",gt.static="static",gt.deprecated="deprecated",gt.abstract="abstract",gt.async="async",gt.modification="modification",gt.documentation="documentation",gt.defaultLibrary="defaultLibrary",(ft||(ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(ht=mt||(mt={})).create=function(e,t){return{range:e,text:t}},ht.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.string(t.text)},(vt=pt||(pt={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},vt.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.boolean(t.caseSensitiveLookup)&&(Ut.string(t.variableName)||void 0===t.variableName)},(_t=bt||(bt={})).create=function(e,t){return{range:e,expression:t}},_t.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&(Ut.string(t.expression)||void 0===t.expression)},(wt=kt||(kt={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},wt.is=function(e){const t=e;return Ut.defined(t)&&k.is(e.stoppedLocation)},(xt=yt||(yt={})).Type=1,xt.Parameter=2,xt.is=function(e){return 1===e||2===e},(Et=It||(It={})).create=function(e){return{value:e}},Et.is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.location||y.is(t.location))&&(void 0===t.command||z.is(t.command))},(At=St||(St={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},At.is=function(e){const t=e;return Ut.objectLiteral(t)&&b.is(t.position)&&(Ut.string(t.label)||Ut.typedArray(t.label,It.is))&&(void 0===t.kind||yt.is(t.kind))&&void 0===t.textEdits||Ut.typedArray(t.textEdits,B.is)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.paddingLeft||Ut.boolean(t.paddingLeft))&&(void 0===t.paddingRight||Ut.boolean(t.paddingRight))},(Ct||(Ct={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Rt||(Rt={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},(Lt||(Lt={})).create=function(e){return{items:e}},(Mt=Tt||(Tt={})).Invoked=0,Mt.Automatic=1,(Pt||(Pt={})).create=function(e,t){return{range:e,text:t}},(Dt||(Dt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(Ft||(Ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&f.is(t.uri)&&Ut.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),o=e.slice(r);t(i,n),t(o,n);let a=0,s=0,u=0;for(;a{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),o=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],a=e.offsetAt(n.range.start),s=e.offsetAt(n.range.end);if(!(s<=o))throw new Error("Overlapping edit");r=r.substring(0,a)+n.newText+r.substring(s,r.length),o=a}return r}}(jt||(jt={}));var Ut,Vt=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return b.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return b.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1{let t,n=e.getLanguageId();n===this._languageId&&(this._listener[e.uri.toString()]=e.onDidChangeContent((()=>{window.clearTimeout(t),t=window.setTimeout((()=>this._doValidate(e.uri,n)),500)})),this._doValidate(e.uri,n))},i=e=>{l.editor.setModelMarkers(e,this._languageId,[]);let t=e.uri.toString(),n=this._listener[t];n&&(n.dispose(),delete this._listener[t])};this._disposables.push(l.editor.onDidCreateModel(r)),this._disposables.push(l.editor.onWillDisposeModel(i)),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{i(e.model),r(e.model)}))),this._disposables.push(n((e=>{l.editor.getModels().forEach((e=>{e.getLanguageId()===this._languageId&&(i(e),r(e))}))}))),this._disposables.push({dispose:()=>{l.editor.getModels().forEach(i);for(let e in this._listener)this._listener[e].dispose()}}),l.editor.getModels().forEach(r)}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables.length=0}_doValidate(e,t){this._worker(e).then((t=>t.doValidation(e.toString()))).then((n=>{const r=n.map((e=>function(e,t){let n="number"===typeof t.code?String(t.code):t.code;return{severity:Wt(t.severity),startLineNumber:t.range.start.line+1,startColumn:t.range.start.character+1,endLineNumber:t.range.end.line+1,endColumn:t.range.end.character+1,message:t.message,code:n,source:t.source}}(0,e)));let i=l.editor.getModel(e);i&&i.getLanguageId()===t&&l.editor.setModelMarkers(i,t,r)})).then(void 0,(e=>{console.error(e)}))}};function Wt(e){switch(e){case U.Error:return l.MarkerSeverity.Error;case U.Warning:return l.MarkerSeverity.Warning;case U.Information:return l.MarkerSeverity.Info;case U.Hint:return l.MarkerSeverity.Hint;default:return l.MarkerSeverity.Info}}var Ht=class{constructor(e,t){this._worker=e,this._triggerCharacters=t}get triggerCharacters(){return this._triggerCharacters}provideCompletionItems(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doComplete(i.toString(),Kt(t)))).then((n=>{if(!n)return;const r=e.getWordUntilPosition(t),i=new l.Range(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn),o=n.items.map((e=>{const t={label:e.label,insertText:e.insertText||e.label,sortText:e.sortText,filterText:e.filterText,documentation:e.documentation,detail:e.detail,command:(n=e.command,n&&"editor.action.triggerSuggest"===n.command?{id:n.command,title:n.title,arguments:n.arguments}:void 0),range:i,kind:$t(e.kind)};var n,r;return e.textEdit&&("undefined"!==typeof(r=e.textEdit).insert&&"undefined"!==typeof r.replace?t.range={insert:zt(e.textEdit.insert),replace:zt(e.textEdit.replace)}:t.range=zt(e.textEdit.range),t.insertText=e.textEdit.newText),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),e.insertTextFormat===ye.Snippet&&(t.insertTextRules=l.languages.CompletionItemInsertTextRule.InsertAsSnippet),t}));return{isIncomplete:n.isIncomplete,suggestions:o}}))}};function Kt(e){if(e)return{character:e.column-1,line:e.lineNumber-1}}function Xt(e){if(e)return{start:{line:e.startLineNumber-1,character:e.startColumn-1},end:{line:e.endLineNumber-1,character:e.endColumn-1}}}function zt(e){if(e)return new l.Range(e.start.line+1,e.start.character+1,e.end.line+1,e.end.character+1)}function $t(e){const t=l.languages.CompletionItemKind;switch(e){case ke.Text:return t.Text;case ke.Method:return t.Method;case ke.Function:return t.Function;case ke.Constructor:return t.Constructor;case ke.Field:return t.Field;case ke.Variable:return t.Variable;case ke.Class:return t.Class;case ke.Interface:return t.Interface;case ke.Module:return t.Module;case ke.Property:return t.Property;case ke.Unit:return t.Unit;case ke.Value:return t.Value;case ke.Enum:return t.Enum;case ke.Keyword:return t.Keyword;case ke.Snippet:return t.Snippet;case ke.Color:return t.Color;case ke.File:return t.File;case ke.Reference:return t.Reference}return t.Property}function Bt(e){if(e)return{range:zt(e.range),text:e.newText}}var qt=class{constructor(e){this._worker=e}provideHover(e,t,n){let r=e.uri;return this._worker(r).then((e=>e.doHover(r.toString(),Kt(t)))).then((e=>{if(e)return{range:zt(e.range),contents:Gt(e.contents)}}))}};function Qt(e){return"string"===typeof e?{value:e}:(t=e)&&"object"===typeof t&&"string"===typeof t.kind?"plaintext"===e.kind?{value:e.value.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}:{value:e.value}:{value:"```"+e.language+"\n"+e.value+"\n```\n"};var t}function Gt(e){if(e)return Array.isArray(e)?e.map(Qt):[Qt(e)]}var Jt=class{constructor(e){this._worker=e}provideDocumentHighlights(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDocumentHighlights(r.toString(),Kt(t)))).then((e=>{if(e)return e.map((e=>({range:zt(e.range),kind:Yt(e.kind)})))}))}};function Yt(e){switch(e){case Ne.Read:return l.languages.DocumentHighlightKind.Read;case Ne.Write:return l.languages.DocumentHighlightKind.Write;case Ne.Text:return l.languages.DocumentHighlightKind.Text}return l.languages.DocumentHighlightKind.Text}var Zt=class{constructor(e){this._worker=e}provideDefinition(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDefinition(r.toString(),Kt(t)))).then((e=>{if(e)return[en(e)]}))}};function en(e){return{uri:l.Uri.parse(e.uri),range:zt(e.range)}}var tn=class{constructor(e){this._worker=e}provideReferences(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.findReferences(i.toString(),Kt(t)))).then((e=>{if(e)return e.map(en)}))}},nn=class{constructor(e){this._worker=e}provideRenameEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doRename(i.toString(),Kt(t),n))).then((e=>function(e){if(!e||!e.changes)return;let t=[];for(let n in e.changes){const r=l.Uri.parse(n);for(let i of e.changes[n])t.push({resource:r,versionId:void 0,textEdit:{range:zt(i.range),text:i.newText}})}return{edits:t}}(e)))}};var rn=class{constructor(e){this._worker=e}provideDocumentSymbols(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentSymbols(n.toString()))).then((e=>{if(e)return e.map((e=>"children"in e?on(e):{name:e.name,detail:"",containerName:e.containerName,kind:an(e.kind),range:zt(e.location.range),selectionRange:zt(e.location.range),tags:[]}))}))}};function on(e){return{name:e.name,detail:e.detail??"",kind:an(e.kind),range:zt(e.range),selectionRange:zt(e.selectionRange),tags:e.tags??[],children:(e.children??[]).map((e=>on(e)))}}function an(e){let t=l.languages.SymbolKind;switch(e){case Oe.File:return t.File;case Oe.Module:return t.Module;case Oe.Namespace:return t.Namespace;case Oe.Package:return t.Package;case Oe.Class:return t.Class;case Oe.Method:return t.Method;case Oe.Property:return t.Property;case Oe.Field:return t.Field;case Oe.Constructor:return t.Constructor;case Oe.Enum:return t.Enum;case Oe.Interface:return t.Interface;case Oe.Function:return t.Function;case Oe.Variable:return t.Variable;case Oe.Constant:return t.Constant;case Oe.String:return t.String;case Oe.Number:return t.Number;case Oe.Boolean:return t.Boolean;case Oe.Array:return t.Array}return t.Function}var sn=class{constructor(e){this._worker=e}provideLinks(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentLinks(n.toString()))).then((e=>{if(e)return{links:e.map((e=>({range:zt(e.range),url:e.target})))}}))}},un=class{constructor(e){this._worker=e}provideDocumentFormattingEdits(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.format(r.toString(),null,dn(t)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}},cn=class{constructor(e){this._worker=e,this.canFormatMultipleRanges=!1}provideDocumentRangeFormattingEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.format(i.toString(),Xt(t),dn(n)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}};function dn(e){return{tabSize:e.tabSize,insertSpaces:e.insertSpaces}}var ln=class{constructor(e){this._worker=e}provideDocumentColors(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentColors(n.toString()))).then((e=>{if(e)return e.map((e=>({color:e.color,range:zt(e.range)})))}))}provideColorPresentations(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getColorPresentations(r.toString(),t.color,Xt(t.range)))).then((e=>{if(e)return e.map((e=>{let t={label:e.label};return e.textEdit&&(t.textEdit=Bt(e.textEdit)),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),t}))}))}},gn=class{constructor(e){this._worker=e}provideFoldingRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getFoldingRanges(r.toString(),t))).then((e=>{if(e)return e.map((e=>{const t={start:e.startLine+1,end:e.endLine+1};return"undefined"!==typeof e.kind&&(t.kind=function(e){switch(e){case M.Comment:return l.languages.FoldingRangeKind.Comment;case M.Imports:return l.languages.FoldingRangeKind.Imports;case M.Region:return l.languages.FoldingRangeKind.Region}return}(e.kind)),t}))}))}};var fn=class{constructor(e){this._worker=e}provideSelectionRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getSelectionRanges(r.toString(),t.map(Kt)))).then((e=>{if(e)return e.map((e=>{const t=[];for(;e;)t.push({range:zt(e.range)}),e=e.parent;return t}))}))}},mn=class extends Ht{constructor(e){super(e,[".",":","<",'"',"=","/"])}};function hn(e){const t=new Nt(e),n=(...e)=>t.getLanguageServiceWorker(...e);let r=e.languageId;l.languages.registerCompletionItemProvider(r,new mn(n)),l.languages.registerHoverProvider(r,new qt(n)),l.languages.registerDocumentHighlightProvider(r,new Jt(n)),l.languages.registerLinkProvider(r,new sn(n)),l.languages.registerFoldingRangeProvider(r,new gn(n)),l.languages.registerDocumentSymbolProvider(r,new rn(n)),l.languages.registerSelectionRangeProvider(r,new fn(n)),l.languages.registerRenameProvider(r,new nn(n)),"html"===r&&(l.languages.registerDocumentFormattingEditProvider(r,new un(n)),l.languages.registerDocumentRangeFormattingEditProvider(r,new cn(n)))}function pn(e){const t=[],n=[],r=new Nt(e);t.push(r);const i=(...e)=>r.getLanguageServiceWorker(...e);return function(){const{languageId:t,modeConfiguration:r}=e;bn(n),r.completionItems&&n.push(l.languages.registerCompletionItemProvider(t,new mn(i))),r.hovers&&n.push(l.languages.registerHoverProvider(t,new qt(i))),r.documentHighlights&&n.push(l.languages.registerDocumentHighlightProvider(t,new Jt(i))),r.links&&n.push(l.languages.registerLinkProvider(t,new sn(i))),r.documentSymbols&&n.push(l.languages.registerDocumentSymbolProvider(t,new rn(i))),r.rename&&n.push(l.languages.registerRenameProvider(t,new nn(i))),r.foldingRanges&&n.push(l.languages.registerFoldingRangeProvider(t,new gn(i))),r.selectionRanges&&n.push(l.languages.registerSelectionRangeProvider(t,new fn(i))),r.documentFormattingEdits&&n.push(l.languages.registerDocumentFormattingEditProvider(t,new un(i))),r.documentRangeFormattingEdits&&n.push(l.languages.registerDocumentRangeFormattingEditProvider(t,new cn(i)))}(),t.push(vn(n)),vn(t)}function vn(e){return{dispose:()=>bn(e)}}function bn(e){for(;e.length;)e.pop().dispose()}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7206.6b7278f5.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/68821.a96b8277.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/7206.6b7278f5.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/68821.a96b8277.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/68990.59087cc5.chunk.js b/ydb/core/viewer/monitoring/static/js/68990.59087cc5.chunk.js new file mode 100644 index 000000000000..3f67fcd3b0c9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/68990.59087cc5.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[68990],{257:e=>{function t(e){e.languages.applescript={comment:[/\(\*(?:\(\*(?:[^*]|\*(?!\)))*\*\)|(?!\(\*)[\s\S])*?\*\)/,/--.+/,/#.+/],string:/"(?:\\.|[^"\\\r\n])*"/,number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e-?\d+)?\b/i,operator:[/[&=\u2260\u2264\u2265*+\-\/\xf7^]|[<>]=?/,/\b(?:(?:begin|end|start)s? with|(?:contains?|(?:does not|doesn't) contain)|(?:is|isn't|is not) (?:contained by|in)|(?:(?:is|isn't|is not) )?(?:greater|less) than(?: or equal)?(?: to)?|(?:comes|(?:does not|doesn't) come) (?:after|before)|(?:is|isn't|is not) equal(?: to)?|(?:(?:does not|doesn't) equal|equal to|equals|is not|isn't)|(?:a )?(?:ref(?: to)?|reference to)|(?:and|as|div|mod|not|or))\b/],keyword:/\b(?:about|above|after|against|apart from|around|aside from|at|back|before|beginning|behind|below|beneath|beside|between|but|by|considering|continue|copy|does|eighth|else|end|equal|error|every|exit|false|fifth|first|for|fourth|from|front|get|given|global|if|ignoring|in|instead of|into|is|it|its|last|local|me|middle|my|ninth|of|on|onto|out of|over|prop|property|put|repeat|return|returning|second|set|seventh|since|sixth|some|tell|tenth|that|the|then|third|through|thru|timeout|times|to|transaction|true|try|until|where|while|whose|with|without)\b/,"class-name":/\b(?:POSIX file|RGB color|alias|application|boolean|centimeters|centimetres|class|constant|cubic centimeters|cubic centimetres|cubic feet|cubic inches|cubic meters|cubic metres|cubic yards|date|degrees Celsius|degrees Fahrenheit|degrees Kelvin|feet|file|gallons|grams|inches|integer|kilograms|kilometers|kilometres|list|liters|litres|meters|metres|miles|number|ounces|pounds|quarts|real|record|reference|script|square feet|square kilometers|square kilometres|square meters|square metres|square miles|square yards|text|yards)\b/,punctuation:/[{}():,\xac\xab\xbb\u300a\u300b]/}}e.exports=t,t.displayName="applescript",t.aliases=[]},68990:(e,t,s)=>{s.d(t,{default:()=>r});var i=s(257);const r=s.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/69220.b99a5ded.chunk.js b/ydb/core/viewer/monitoring/static/js/69220.b99a5ded.chunk.js new file mode 100644 index 000000000000..e55d4b5d5cf2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/69220.b99a5ded.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[69220],{46839:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"sv",weekdays:"s\xf6ndag_m\xe5ndag_tisdag_onsdag_torsdag_fredag_l\xf6rdag".split("_"),weekdaysShort:"s\xf6n_m\xe5n_tis_ons_tor_fre_l\xf6r".split("_"),weekdaysMin:"s\xf6_m\xe5_ti_on_to_fr_l\xf6".split("_"),months:"januari_februari_mars_april_maj_juni_juli_augusti_september_oktober_november_december".split("_"),monthsShort:"jan_feb_mar_apr_maj_jun_jul_aug_sep_okt_nov_dec".split("_"),weekStart:1,yearStart:4,ordinal:function(e){var a=e%10;return"["+e+(1===a||2===a?"a":"e")+"]"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [kl.] HH:mm",LLLL:"dddd D MMMM YYYY [kl.] HH:mm",lll:"D MMM YYYY HH:mm",llll:"ddd D MMM YYYY HH:mm"},relativeTime:{future:"om %s",past:"f\xf6r %s sedan",s:"n\xe5gra sekunder",m:"en minut",mm:"%d minuter",h:"en timme",hh:"%d timmar",d:"en dag",dd:"%d dagar",M:"en m\xe5nad",MM:"%d m\xe5nader",y:"ett \xe5r",yy:"%d \xe5r"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/69500.7fbd370c.chunk.js b/ydb/core/viewer/monitoring/static/js/69500.7fbd370c.chunk.js new file mode 100644 index 000000000000..76e001c1e724 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/69500.7fbd370c.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[69500],{69500:(e,a,i)=>{i.d(a,{default:()=>l});var t=i(87137);const l=i.n(t)()},87137:e=>{function a(e){e.languages.gedcom={"line-value":{pattern:/(^[\t ]*\d+ +(?:@\w[\w!"$%&'()*+,\-./:;<=>?[\\\]^`{|}~\x80-\xfe #]*@ +)?\w+ ).+/m,lookbehind:!0,inside:{pointer:{pattern:/^@\w[\w!"$%&'()*+,\-./:;<=>?[\\\]^`{|}~\x80-\xfe #]*@$/,alias:"variable"}}},tag:{pattern:/(^[\t ]*\d+ +(?:@\w[\w!"$%&'()*+,\-./:;<=>?[\\\]^`{|}~\x80-\xfe #]*@ +)?)\w+/m,lookbehind:!0,alias:"string"},level:{pattern:/(^[\t ]*)\d+/m,lookbehind:!0,alias:"number"},pointer:{pattern:/@\w[\w!"$%&'()*+,\-./:;<=>?[\\\]^`{|}~\x80-\xfe #]*@/,alias:"variable"}}}e.exports=a,a.displayName="gedcom",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/69712.983d0bad.chunk.js b/ydb/core/viewer/monitoring/static/js/69712.983d0bad.chunk.js new file mode 100644 index 000000000000..1e960db3f878 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/69712.983d0bad.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[69712],{69712:(e,a,t)=>{t.d(a,{default:()=>s});var i=t(95649);const s=t.n(i)()},95649:e=>{function a(e){e.languages.actionscript=e.languages.extend("javascript",{keyword:/\b(?:as|break|case|catch|class|const|default|delete|do|dynamic|each|else|extends|final|finally|for|function|get|if|implements|import|in|include|instanceof|interface|internal|is|namespace|native|new|null|override|package|private|protected|public|return|set|static|super|switch|this|throw|try|typeof|use|var|void|while|with)\b/,operator:/\+\+|--|(?:[+\-*\/%^]|&&?|\|\|?|<>?>?|[!=]=?)=?|[~?@]/}),e.languages.actionscript["class-name"].alias="function",delete e.languages.actionscript.parameter,delete e.languages.actionscript["literal-property"],e.languages.markup&&e.languages.insertBefore("actionscript","string",{xml:{pattern:/(^|[^.])<\/?\w+(?:\s+[^\s>\/=]+=("|')(?:\\[\s\S]|(?!\2)[^\\])*\2)*\s*\/?>/,lookbehind:!0,inside:e.languages.markup}})}e.exports=a,a.displayName="actionscript",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/69854.1159f91a.chunk.js b/ydb/core/viewer/monitoring/static/js/69854.1159f91a.chunk.js new file mode 100644 index 000000000000..d1e889d890bb --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/69854.1159f91a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[69854],{28329:(e,n,t)=>{var r=t(90160),a=t(51572);function i(e){e.register(r),e.register(a),function(e){e.languages.erb={delimiter:{pattern:/^(\s*)<%=?|%>(?=\s*$)/,lookbehind:!0,alias:"punctuation"},ruby:{pattern:/\s*\S[\s\S]*/,alias:"language-ruby",inside:e.languages.ruby}},e.hooks.add("before-tokenize",(function(n){e.languages["markup-templating"].buildPlaceholders(n,"erb",/<%=?(?:[^\r\n]|[\r\n](?!=begin)|[\r\n]=begin\s(?:[^\r\n]|[\r\n](?!=end))*[\r\n]=end)+?%>/g)})),e.hooks.add("after-tokenize",(function(n){e.languages["markup-templating"].tokenizePlaceholders(n,"erb")}))}(e)}e.exports=i,i.displayName="erb",i.aliases=[]},51572:e=>{function n(e){!function(e){function n(e,n){return"___"+e.toUpperCase()+n+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,r,a,i){if(t.language===r){var s=t.tokenStack=[];t.code=t.code.replace(a,(function(e){if("function"===typeof i&&!i(e))return e;for(var a,o=s.length;-1!==t.code.indexOf(a=n(r,o));)++o;return s[o]=e,a})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,r){if(t.language===r&&t.tokenStack){t.grammar=e.languages[r];var a=0,i=Object.keys(t.tokenStack);!function s(o){for(var l=0;l=i.length);l++){var u=o[l];if("string"===typeof u||u.content&&"string"===typeof u.content){var g=i[a],d=t.tokenStack[g],c="string"===typeof u?u:u.content,p=n(r,g),b=c.indexOf(p);if(b>-1){++a;var m=c.substring(0,b),f=new e.Token(r,e.tokenize(d,t.grammar),"language-"+r,d),y=c.substring(b+p.length),h=[];m&&h.push.apply(h,s([m])),h.push(f),y&&h.push.apply(h,s([y])),"string"===typeof u?o.splice.apply(o,[l,1].concat(h)):u.content=h}}else u.content&&s(u.content)}return o}(t.tokens)}}}})}(e)}e.exports=n,n.displayName="markupTemplating",n.aliases=[]},69854:(e,n,t)=>{t.d(n,{default:()=>a});var r=t(28329);const a=t.n(r)()},90160:e=>{function n(e){!function(e){e.languages.ruby=e.languages.extend("clike",{comment:{pattern:/#.*|^=begin\s[\s\S]*?^=end/m,greedy:!0},"class-name":{pattern:/(\b(?:class|module)\s+|\bcatch\s+\()[\w.\\]+|\b[A-Z_]\w*(?=\s*\.\s*new\b)/,lookbehind:!0,inside:{punctuation:/[.\\]/}},keyword:/\b(?:BEGIN|END|alias|and|begin|break|case|class|def|define_method|defined|do|each|else|elsif|end|ensure|extend|for|if|in|include|module|new|next|nil|not|or|prepend|private|protected|public|raise|redo|require|rescue|retry|return|self|super|then|throw|undef|unless|until|when|while|yield)\b/,operator:/\.{2,3}|&\.|===||[!=]?~|(?:&&|\|\||<<|>>|\*\*|[+\-*/%<>!^&|=])=?|[?:]/,punctuation:/[(){}[\].,;]/}),e.languages.insertBefore("ruby","operator",{"double-colon":{pattern:/::/,alias:"punctuation"}});var n={pattern:/((?:^|[^\\])(?:\\{2})*)#\{(?:[^{}]|\{[^{}]*\})*\}/,lookbehind:!0,inside:{content:{pattern:/^(#\{)[\s\S]+(?=\}$)/,lookbehind:!0,inside:e.languages.ruby},delimiter:{pattern:/^#\{|\}$/,alias:"punctuation"}}};delete e.languages.ruby.function;var t="(?:"+[/([^a-zA-Z0-9\s{(\[<=])(?:(?!\1)[^\\]|\\[\s\S])*\1/.source,/\((?:[^()\\]|\\[\s\S]|\((?:[^()\\]|\\[\s\S])*\))*\)/.source,/\{(?:[^{}\\]|\\[\s\S]|\{(?:[^{}\\]|\\[\s\S])*\})*\}/.source,/\[(?:[^\[\]\\]|\\[\s\S]|\[(?:[^\[\]\\]|\\[\s\S])*\])*\]/.source,/<(?:[^<>\\]|\\[\s\S]|<(?:[^<>\\]|\\[\s\S])*>)*>/.source].join("|")+")",r=/(?:"(?:\\.|[^"\\\r\n])*"|(?:\b[a-zA-Z_]\w*|[^\s\0-\x7F]+)[?!]?|\$.)/.source;e.languages.insertBefore("ruby","keyword",{"regex-literal":[{pattern:RegExp(/%r/.source+t+/[egimnosux]{0,6}/.source),greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}},{pattern:/(^|[^/])\/(?!\/)(?:\[[^\r\n\]]+\]|\\.|[^[/\\\r\n])+\/[egimnosux]{0,6}(?=\s*(?:$|[\r\n,.;})#]))/,lookbehind:!0,greedy:!0,inside:{interpolation:n,regex:/[\s\S]+/}}],variable:/[@$]+[a-zA-Z_]\w*(?:[?!]|\b)/,symbol:[{pattern:RegExp(/(^|[^:]):/.source+r),lookbehind:!0,greedy:!0},{pattern:RegExp(/([\r\n{(,][ \t]*)/.source+r+/(?=:(?!:))/.source),lookbehind:!0,greedy:!0}],"method-definition":{pattern:/(\bdef\s+)\w+(?:\s*\.\s*\w+)?/,lookbehind:!0,inside:{function:/\b\w+$/,keyword:/^self\b/,"class-name":/^\w+/,punctuation:/\./}}}),e.languages.insertBefore("ruby","string",{"string-literal":[{pattern:RegExp(/%[qQiIwWs]?/.source+t),greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/("|')(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|(?!\1)[^\\#\r\n])*\1/,greedy:!0,inside:{interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?([a-z_]\w*)[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?[a-z_]\w*|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?/}},interpolation:n,string:/[\s\S]+/}},{pattern:/<<[-~]?'([a-z_]\w*)'[\r\n](?:.*[\r\n])*?[\t ]*\1/i,alias:"heredoc-string",greedy:!0,inside:{delimiter:{pattern:/^<<[-~]?'[a-z_]\w*'|\b[a-z_]\w*$/i,inside:{symbol:/\b\w+/,punctuation:/^<<[-~]?'|'$/}},string:/[\s\S]+/}}],"command-literal":[{pattern:RegExp(/%x/.source+t),greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}},{pattern:/`(?:#\{[^}]+\}|#(?!\{)|\\(?:\r\n|[\s\S])|[^\\`#\r\n])*`/,greedy:!0,inside:{interpolation:n,command:{pattern:/[\s\S]+/,alias:"string"}}}]}),delete e.languages.ruby.string,e.languages.insertBefore("ruby","number",{builtin:/\b(?:Array|Bignum|Binding|Class|Continuation|Dir|Exception|FalseClass|File|Fixnum|Float|Hash|IO|Integer|MatchData|Method|Module|NilClass|Numeric|Object|Proc|Range|Regexp|Stat|String|Struct|Symbol|TMS|Thread|ThreadGroup|Time|TrueClass)\b/,constant:/\b[A-Z][A-Z0-9_]*(?:[?!]|\b)/}),e.languages.rb=e.languages.ruby}(e)}e.exports=n,n.displayName="ruby",n.aliases=["rb"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/6990.70257b9b.chunk.js b/ydb/core/viewer/monitoring/static/js/6990.70257b9b.chunk.js deleted file mode 100644 index 259700e2fe8f..000000000000 --- a/ydb/core/viewer/monitoring/static/js/6990.70257b9b.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[6990],{56990:(e,l,t)=>{t.r(l),t.d(l,{ReactComponent:()=>m,default:()=>h});var a,r,i,n,c,d,o,s,f=t(59284);function u(){return u=Object.assign?Object.assign.bind():function(e){for(var l=1;l{function t(e){!function(e){e.languages.xquery=e.languages.extend("markup",{"xquery-comment":{pattern:/\(:[\s\S]*?:\)/,greedy:!0,alias:"comment"},string:{pattern:/(["'])(?:\1\1|(?!\1)[\s\S])*\1/,greedy:!0},extension:{pattern:/\(#.+?#\)/,alias:"symbol"},variable:/\$[-\w:]+/,axis:{pattern:/(^|[^-])(?:ancestor(?:-or-self)?|attribute|child|descendant(?:-or-self)?|following(?:-sibling)?|parent|preceding(?:-sibling)?|self)(?=::)/,lookbehind:!0,alias:"operator"},"keyword-operator":{pattern:/(^|[^:-])\b(?:and|castable as|div|eq|except|ge|gt|idiv|instance of|intersect|is|le|lt|mod|ne|or|union)\b(?=$|[^:-])/,lookbehind:!0,alias:"operator"},keyword:{pattern:/(^|[^:-])\b(?:as|ascending|at|base-uri|boundary-space|case|cast as|collation|construction|copy-namespaces|declare|default|descending|else|empty (?:greatest|least)|encoding|every|external|for|function|if|import|in|inherit|lax|let|map|module|namespace|no-inherit|no-preserve|option|order(?: by|ed|ing)?|preserve|return|satisfies|schema|some|stable|strict|strip|then|to|treat as|typeswitch|unordered|validate|variable|version|where|xquery)\b(?=$|[^:-])/,lookbehind:!0},function:/[\w-]+(?::[\w-]+)*(?=\s*\()/,"xquery-element":{pattern:/(element\s+)[\w-]+(?::[\w-]+)*/,lookbehind:!0,alias:"tag"},"xquery-attribute":{pattern:/(attribute\s+)[\w-]+(?::[\w-]+)*/,lookbehind:!0,alias:"attr-name"},builtin:{pattern:/(^|[^:-])\b(?:attribute|comment|document|element|processing-instruction|text|xs:(?:ENTITIES|ENTITY|ID|IDREFS?|NCName|NMTOKENS?|NOTATION|Name|QName|anyAtomicType|anyType|anyURI|base64Binary|boolean|byte|date|dateTime|dayTimeDuration|decimal|double|duration|float|gDay|gMonth|gMonthDay|gYear|gYearMonth|hexBinary|int|integer|language|long|negativeInteger|nonNegativeInteger|nonPositiveInteger|normalizedString|positiveInteger|short|string|time|token|unsigned(?:Byte|Int|Long|Short)|untyped(?:Atomic)?|yearMonthDuration))\b(?=$|[^:-])/,lookbehind:!0},number:/\b\d+(?:\.\d+)?(?:E[+-]?\d+)?/,operator:[/[+*=?|@]|\.\.?|:=|!=|<[=<]?|>[=>]?/,{pattern:/(\s)-(?=\s)/,lookbehind:!0}],punctuation:/[[\](){},;:/]/}),e.languages.xquery.tag.pattern=/<\/?(?!\d)[^\s>\/=$<%]+(?:\s+[^\s>\/=]+(?:=(?:("|')(?:\\[\s\S]|\{(?!\{)(?:\{(?:\{[^{}]*\}|[^{}])*\}|[^{}])+\}|(?!\1)[^\\])*\1|[^\s'">=]+))?)*\s*\/?>/,e.languages.xquery.tag.inside["attr-value"].pattern=/=(?:("|')(?:\\[\s\S]|\{(?!\{)(?:\{(?:\{[^{}]*\}|[^{}])*\}|[^{}])+\}|(?!\1)[^\\])*\1|[^\s'">=]+)/,e.languages.xquery.tag.inside["attr-value"].inside.punctuation=/^="|"$/,e.languages.xquery.tag.inside["attr-value"].inside.expression={pattern:/\{(?!\{)(?:\{(?:\{[^{}]*\}|[^{}])*\}|[^{}])+\}/,inside:e.languages.xquery,alias:"language-xquery"};var t=function(e){return"string"===typeof e?e:"string"===typeof e.content?e.content:e.content.map(t).join("")},n=function(a){for(var o=[],i=0;i0&&o[o.length-1].tagName===t(r.content[0].content[1])&&o.pop():"/>"===r.content[r.content.length-1].content||o.push({tagName:t(r.content[0].content[1]),openedBraces:0}):!(o.length>0&&"punctuation"===r.type&&"{"===r.content)||a[i+1]&&"punctuation"===a[i+1].type&&"{"===a[i+1].content||a[i-1]&&"plain-text"===a[i-1].type&&"{"===a[i-1].content?o.length>0&&o[o.length-1].openedBraces>0&&"punctuation"===r.type&&"}"===r.content?o[o.length-1].openedBraces--:"comment"!==r.type&&(s=!0):o[o.length-1].openedBraces++),(s||"string"===typeof r)&&o.length>0&&0===o[o.length-1].openedBraces){var l=t(r);i0&&("string"===typeof a[i-1]||"plain-text"===a[i-1].type)&&(l=t(a[i-1])+l,a.splice(i-1,1),i--),/^\s+$/.test(l)?a[i]=l:a[i]=new e.Token("plain-text",l,null,l)}r.content&&"string"!==typeof r.content&&n(r.content)}};e.hooks.add("after-tokenize",(function(e){"xquery"===e.language&&n(e.tokens)}))}(e)}e.exports=t,t.displayName="xquery",t.aliases=[]},69997:(e,t,n)=>{n.d(t,{default:()=>o});var a=n(56748);const o=n.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/70190.e3137ef3.chunk.js b/ydb/core/viewer/monitoring/static/js/70190.e3137ef3.chunk.js new file mode 100644 index 000000000000..b7569020538d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/70190.e3137ef3.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[70190],{54431:e=>{function a(e){!function(e){var a=/\{[^\r\n\[\]{}]*\}/,n={"quoted-string":{pattern:/"(?:[^"\\]|\\.)*"/,alias:"operator"},"command-param-id":{pattern:/(\s)\w+:/,lookbehind:!0,alias:"property"},"command-param-value":[{pattern:a,alias:"selector"},{pattern:/([\t ])\S+/,lookbehind:!0,greedy:!0,alias:"operator"},{pattern:/\S(?:.*\S)?/,alias:"operator"}]};function t(e){return"string"===typeof e?e:Array.isArray(e)?e.map(t).join(""):t(e.content)}e.languages.naniscript={comment:{pattern:/^([\t ]*);.*/m,lookbehind:!0},define:{pattern:/^>.+/m,alias:"tag",inside:{value:{pattern:/(^>\w+[\t ]+)(?!\s)[^{}\r\n]+/,lookbehind:!0,alias:"operator"},key:{pattern:/(^>)\w+/,lookbehind:!0}}},label:{pattern:/^([\t ]*)#[\t ]*\w+[\t ]*$/m,lookbehind:!0,alias:"regex"},command:{pattern:/^([\t ]*)@\w+(?=[\t ]|$).*/m,lookbehind:!0,alias:"function",inside:{"command-name":/^@\w+/,expression:{pattern:a,greedy:!0,alias:"selector"},"command-params":{pattern:/\s*\S[\s\S]*/,inside:n}}},"generic-text":{pattern:/(^[ \t]*)[^#@>;\s].*/m,lookbehind:!0,alias:"punctuation",inside:{"escaped-char":/\\[{}\[\]"]/,expression:{pattern:a,greedy:!0,alias:"selector"},"inline-command":{pattern:/\[[\t ]*\w[^\r\n\[\]]*\]/,greedy:!0,alias:"function",inside:{"command-params":{pattern:/(^\[[\t ]*\w+\b)[\s\S]+(?=\]$)/,lookbehind:!0,inside:n},"command-param-name":{pattern:/^(\[[\t ]*)\w+/,lookbehind:!0,alias:"name"},"start-stop-char":/[\[\]]/}}}}},e.languages.nani=e.languages.naniscript,e.hooks.add("after-tokenize",(function(e){e.tokens.forEach((function(e){if("string"!==typeof e&&"generic-text"===e.type){var a=t(e);(function(e){for(var a="[]{}",n=[],t=0;t{n.d(a,{default:()=>i});var t=n(54431);const i=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/70225.f064b5ad.chunk.js b/ydb/core/viewer/monitoring/static/js/70225.f064b5ad.chunk.js new file mode 100644 index 000000000000..615910b55456 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/70225.f064b5ad.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 70225.f064b5ad.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[70225],{70225:(e,t,n)=>{n.r(t),n.d(t,{CompletionAdapter:()=>Wt,DefinitionAdapter:()=>Zt,DiagnosticsAdapter:()=>Ot,DocumentColorAdapter:()=>ln,DocumentFormattingEditProvider:()=>un,DocumentHighlightAdapter:()=>Jt,DocumentLinkAdapter:()=>sn,DocumentRangeFormattingEditProvider:()=>cn,DocumentSymbolAdapter:()=>rn,FoldingRangeAdapter:()=>gn,HoverAdapter:()=>qt,ReferenceAdapter:()=>tn,RenameAdapter:()=>nn,SelectionRangeAdapter:()=>fn,WorkerManager:()=>Nt,fromPosition:()=>Ht,fromRange:()=>Xt,setupMode:()=>hn,toRange:()=>zt,toTextEdit:()=>Bt});var r,i,o=n(80781),a=Object.defineProperty,s=Object.getOwnPropertyDescriptor,u=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,d=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of u(t))c.call(e,i)||i===n||a(e,i,{get:()=>t[i],enumerable:!(r=s(t,i))||r.enumerable});return e},l={};d(l,r=o,"default"),i&&d(i,r,"default");var g,f,h,p,m,v,b,_,k,y,w,x,I,E,C,A,S,R,L,T,M,D,P,F,j,N,U,V,O,K,W,H,X,z,$,B,q,Q,G,J,Y,Z,ee,te,ne,re,ie,oe,ae,se,ue,ce,de,le,ge,fe,he,pe,me,ve,be,_e,ke,ye,we,xe,Ie,Ee,Ce,Ae,Se,Re,Le,Te,Me,De,Pe,Fe,je,Ne,Ue,Ve,Oe,Ke,We,He,Xe,ze,$e,Be,qe,Qe,Ge,Je,Ye,Ze,et,tt,nt,rt,it,ot,at,st,ut,ct,dt,lt,gt,ft,ht,pt,mt,vt,bt,_t,kt,yt,wt,xt,It,Et,Ct,At,St,Rt,Lt,Tt,Mt,Dt,Pt,Ft,jt,Nt=class{constructor(e){this._defaults=e,this._worker=null,this._client=null,this._idleCheckInterval=window.setInterval((()=>this._checkIfIdle()),3e4),this._lastUsedTime=0,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker()))}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}dispose(){clearInterval(this._idleCheckInterval),this._configChangeListener.dispose(),this._stopWorker()}_checkIfIdle(){if(!this._worker)return;Date.now()-this._lastUsedTime>12e4&&this._stopWorker()}_getClient(){return this._lastUsedTime=Date.now(),this._client||(this._worker=l.editor.createWebWorker({moduleId:"vs/language/css/cssWorker",label:this._defaults.languageId,createData:{options:this._defaults.options,languageId:this._defaults.languageId}}),this._client=this._worker.getProxy()),this._client}getLanguageServiceWorker(...e){let t;return this._getClient().then((e=>{t=e})).then((t=>{if(this._worker)return this._worker.withSyncedResources(e)})).then((e=>t))}};(g||(g={})).is=function(e){return"string"===typeof e},(f||(f={})).is=function(e){return"string"===typeof e},(p=h||(h={})).MIN_VALUE=-2147483648,p.MAX_VALUE=2147483647,p.is=function(e){return"number"===typeof e&&p.MIN_VALUE<=e&&e<=p.MAX_VALUE},(v=m||(m={})).MIN_VALUE=0,v.MAX_VALUE=2147483647,v.is=function(e){return"number"===typeof e&&v.MIN_VALUE<=e&&e<=v.MAX_VALUE},(_=b||(b={})).create=function(e,t){return e===Number.MAX_VALUE&&(e=m.MAX_VALUE),t===Number.MAX_VALUE&&(t=m.MAX_VALUE),{line:e,character:t}},_.is=function(e){let t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.line)&&Ut.uinteger(t.character)},(y=k||(k={})).create=function(e,t,n,r){if(Ut.uinteger(e)&&Ut.uinteger(t)&&Ut.uinteger(n)&&Ut.uinteger(r))return{start:b.create(e,t),end:b.create(n,r)};if(b.is(e)&&b.is(t))return{start:e,end:t};throw new Error(`Range#create called with invalid arguments[${e}, ${t}, ${n}, ${r}]`)},y.is=function(e){let t=e;return Ut.objectLiteral(t)&&b.is(t.start)&&b.is(t.end)},(x=w||(w={})).create=function(e,t){return{uri:e,range:t}},x.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(Ut.string(t.uri)||Ut.undefined(t.uri))},(E=I||(I={})).create=function(e,t,n,r){return{targetUri:e,targetRange:t,targetSelectionRange:n,originSelectionRange:r}},E.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.targetRange)&&Ut.string(t.targetUri)&&k.is(t.targetSelectionRange)&&(k.is(t.originSelectionRange)||Ut.undefined(t.originSelectionRange))},(A=C||(C={})).create=function(e,t,n,r){return{red:e,green:t,blue:n,alpha:r}},A.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.numberRange(t.red,0,1)&&Ut.numberRange(t.green,0,1)&&Ut.numberRange(t.blue,0,1)&&Ut.numberRange(t.alpha,0,1)},(R=S||(S={})).create=function(e,t){return{range:e,color:t}},R.is=function(e){const t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&C.is(t.color)},(T=L||(L={})).create=function(e,t,n){return{label:e,textEdit:t,additionalTextEdits:n}},T.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.undefined(t.textEdit)||B.is(t))&&(Ut.undefined(t.additionalTextEdits)||Ut.typedArray(t.additionalTextEdits,B.is))},(D=M||(M={})).Comment="comment",D.Imports="imports",D.Region="region",(F=P||(P={})).create=function(e,t,n,r,i,o){const a={startLine:e,endLine:t};return Ut.defined(n)&&(a.startCharacter=n),Ut.defined(r)&&(a.endCharacter=r),Ut.defined(i)&&(a.kind=i),Ut.defined(o)&&(a.collapsedText=o),a},F.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.startLine)&&Ut.uinteger(t.startLine)&&(Ut.undefined(t.startCharacter)||Ut.uinteger(t.startCharacter))&&(Ut.undefined(t.endCharacter)||Ut.uinteger(t.endCharacter))&&(Ut.undefined(t.kind)||Ut.string(t.kind))},(N=j||(j={})).create=function(e,t){return{location:e,message:t}},N.is=function(e){let t=e;return Ut.defined(t)&&w.is(t.location)&&Ut.string(t.message)},(V=U||(U={})).Error=1,V.Warning=2,V.Information=3,V.Hint=4,(K=O||(O={})).Unnecessary=1,K.Deprecated=2,(W||(W={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.href)},(X=H||(H={})).create=function(e,t,n,r,i,o){let a={range:e,message:t};return Ut.defined(n)&&(a.severity=n),Ut.defined(r)&&(a.code=r),Ut.defined(i)&&(a.source=i),Ut.defined(o)&&(a.relatedInformation=o),a},X.is=function(e){var t;let n=e;return Ut.defined(n)&&k.is(n.range)&&Ut.string(n.message)&&(Ut.number(n.severity)||Ut.undefined(n.severity))&&(Ut.integer(n.code)||Ut.string(n.code)||Ut.undefined(n.code))&&(Ut.undefined(n.codeDescription)||Ut.string(null===(t=n.codeDescription)||void 0===t?void 0:t.href))&&(Ut.string(n.source)||Ut.undefined(n.source))&&(Ut.undefined(n.relatedInformation)||Ut.typedArray(n.relatedInformation,j.is))},($=z||(z={})).create=function(e,t,...n){let r={title:e,command:t};return Ut.defined(n)&&n.length>0&&(r.arguments=n),r},$.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.title)&&Ut.string(t.command)},(q=B||(B={})).replace=function(e,t){return{range:e,newText:t}},q.insert=function(e,t){return{range:{start:e,end:e},newText:t}},q.del=function(e){return{range:e,newText:""}},q.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.newText)&&k.is(t.range)},(G=Q||(Q={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},G.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(Ut.string(t.description)||void 0===t.description)},(J||(J={})).is=function(e){const t=e;return Ut.string(t)},(Z=Y||(Y={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},Z.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},Z.del=function(e,t){return{range:e,newText:"",annotationId:t}},Z.is=function(e){const t=e;return B.is(t)&&(Q.is(t.annotationId)||J.is(t.annotationId))},(te=ee||(ee={})).create=function(e,t){return{textDocument:e,edits:t}},te.is=function(e){let t=e;return Ut.defined(t)&&fe.is(t.textDocument)&&Array.isArray(t.edits)},(re=ne||(ne={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},re.is=function(e){let t=e;return t&&"create"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(oe=ie||(ie={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},oe.is=function(e){let t=e;return t&&"rename"===t.kind&&Ut.string(t.oldUri)&&Ut.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(se=ae||(ae={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},se.is=function(e){let t=e;return t&&"delete"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||Ut.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||Ut.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(ue||(ue={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>Ut.string(e.kind)?ne.is(e)||ie.is(e)||ae.is(e):ee.is(e))))},(de=ce||(ce={})).create=function(e){return{uri:e}},de.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)},(ge=le||(le={})).create=function(e,t){return{uri:e,version:t}},ge.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.integer(t.version)},(he=fe||(fe={})).create=function(e,t){return{uri:e,version:t}},he.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&(null===t.version||Ut.integer(t.version))},(me=pe||(pe={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},me.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.string(t.languageId)&&Ut.integer(t.version)&&Ut.string(t.text)},(be=ve||(ve={})).PlainText="plaintext",be.Markdown="markdown",be.is=function(e){const t=e;return t===be.PlainText||t===be.Markdown},(_e||(_e={})).is=function(e){const t=e;return Ut.objectLiteral(e)&&ve.is(t.kind)&&Ut.string(t.value)},(ye=ke||(ke={})).Text=1,ye.Method=2,ye.Function=3,ye.Constructor=4,ye.Field=5,ye.Variable=6,ye.Class=7,ye.Interface=8,ye.Module=9,ye.Property=10,ye.Unit=11,ye.Value=12,ye.Enum=13,ye.Keyword=14,ye.Snippet=15,ye.Color=16,ye.File=17,ye.Reference=18,ye.Folder=19,ye.EnumMember=20,ye.Constant=21,ye.Struct=22,ye.Event=23,ye.Operator=24,ye.TypeParameter=25,(xe=we||(we={})).PlainText=1,xe.Snippet=2,(Ie||(Ie={})).Deprecated=1,(Ce=Ee||(Ee={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},Ce.is=function(e){const t=e;return t&&Ut.string(t.newText)&&k.is(t.insert)&&k.is(t.replace)},(Se=Ae||(Ae={})).asIs=1,Se.adjustIndentation=2,(Re||(Re={})).is=function(e){const t=e;return t&&(Ut.string(t.detail)||void 0===t.detail)&&(Ut.string(t.description)||void 0===t.description)},(Le||(Le={})).create=function(e){return{label:e}},(Te||(Te={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(De=Me||(Me={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},De.is=function(e){const t=e;return Ut.string(t)||Ut.objectLiteral(t)&&Ut.string(t.language)&&Ut.string(t.value)},(Pe||(Pe={})).is=function(e){let t=e;return!!t&&Ut.objectLiteral(t)&&(_e.is(t.contents)||Me.is(t.contents)||Ut.typedArray(t.contents,Me.is))&&(void 0===e.range||k.is(e.range))},(Fe||(Fe={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(je||(je={})).create=function(e,t,...n){let r={label:e};return Ut.defined(t)&&(r.documentation=t),Ut.defined(n)?r.parameters=n:r.parameters=[],r},(Ue=Ne||(Ne={})).Text=1,Ue.Read=2,Ue.Write=3,(Ve||(Ve={})).create=function(e,t){let n={range:e};return Ut.number(t)&&(n.kind=t),n},(Ke=Oe||(Oe={})).File=1,Ke.Module=2,Ke.Namespace=3,Ke.Package=4,Ke.Class=5,Ke.Method=6,Ke.Property=7,Ke.Field=8,Ke.Constructor=9,Ke.Enum=10,Ke.Interface=11,Ke.Function=12,Ke.Variable=13,Ke.Constant=14,Ke.String=15,Ke.Number=16,Ke.Boolean=17,Ke.Array=18,Ke.Object=19,Ke.Key=20,Ke.Null=21,Ke.EnumMember=22,Ke.Struct=23,Ke.Event=24,Ke.Operator=25,Ke.TypeParameter=26,(We||(We={})).Deprecated=1,(He||(He={})).create=function(e,t,n,r,i){let o={name:e,kind:t,location:{uri:r,range:n}};return i&&(o.containerName=i),o},(Xe||(Xe={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},($e=ze||(ze={})).create=function(e,t,n,r,i,o){let a={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==o&&(a.children=o),a},$e.is=function(e){let t=e;return t&&Ut.string(t.name)&&Ut.number(t.kind)&&k.is(t.range)&&k.is(t.selectionRange)&&(void 0===t.detail||Ut.string(t.detail))&&(void 0===t.deprecated||Ut.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},(qe=Be||(Be={})).Empty="",qe.QuickFix="quickfix",qe.Refactor="refactor",qe.RefactorExtract="refactor.extract",qe.RefactorInline="refactor.inline",qe.RefactorRewrite="refactor.rewrite",qe.Source="source",qe.SourceOrganizeImports="source.organizeImports",qe.SourceFixAll="source.fixAll",(Ge=Qe||(Qe={})).Invoked=1,Ge.Automatic=2,(Ye=Je||(Je={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},Ye.is=function(e){let t=e;return Ut.defined(t)&&Ut.typedArray(t.diagnostics,H.is)&&(void 0===t.only||Ut.typedArray(t.only,Ut.string))&&(void 0===t.triggerKind||t.triggerKind===Qe.Invoked||t.triggerKind===Qe.Automatic)},(et=Ze||(Ze={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):z.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},et.is=function(e){let t=e;return t&&Ut.string(t.title)&&(void 0===t.diagnostics||Ut.typedArray(t.diagnostics,H.is))&&(void 0===t.kind||Ut.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||z.is(t.command))&&(void 0===t.isPreferred||Ut.boolean(t.isPreferred))&&(void 0===t.edit||ue.is(t.edit))},(nt=tt||(tt={})).create=function(e,t){let n={range:e};return Ut.defined(t)&&(n.data=t),n},nt.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.command)||z.is(t.command))},(it=rt||(rt={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},it.is=function(e){let t=e;return Ut.defined(t)&&Ut.uinteger(t.tabSize)&&Ut.boolean(t.insertSpaces)},(at=ot||(ot={})).create=function(e,t,n){return{range:e,target:t,data:n}},at.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.target)||Ut.string(t.target))},(ut=st||(st={})).create=function(e,t){return{range:e,parent:t}},ut.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(void 0===t.parent||ut.is(t.parent))},(dt=ct||(ct={})).namespace="namespace",dt.type="type",dt.class="class",dt.enum="enum",dt.interface="interface",dt.struct="struct",dt.typeParameter="typeParameter",dt.parameter="parameter",dt.variable="variable",dt.property="property",dt.enumMember="enumMember",dt.event="event",dt.function="function",dt.method="method",dt.macro="macro",dt.keyword="keyword",dt.modifier="modifier",dt.comment="comment",dt.string="string",dt.number="number",dt.regexp="regexp",dt.operator="operator",dt.decorator="decorator",(gt=lt||(lt={})).declaration="declaration",gt.definition="definition",gt.readonly="readonly",gt.static="static",gt.deprecated="deprecated",gt.abstract="abstract",gt.async="async",gt.modification="modification",gt.documentation="documentation",gt.defaultLibrary="defaultLibrary",(ft||(ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(pt=ht||(ht={})).create=function(e,t){return{range:e,text:t}},pt.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.string(t.text)},(vt=mt||(mt={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},vt.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.boolean(t.caseSensitiveLookup)&&(Ut.string(t.variableName)||void 0===t.variableName)},(_t=bt||(bt={})).create=function(e,t){return{range:e,expression:t}},_t.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&(Ut.string(t.expression)||void 0===t.expression)},(yt=kt||(kt={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},yt.is=function(e){const t=e;return Ut.defined(t)&&k.is(e.stoppedLocation)},(xt=wt||(wt={})).Type=1,xt.Parameter=2,xt.is=function(e){return 1===e||2===e},(Et=It||(It={})).create=function(e){return{value:e}},Et.is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.location||w.is(t.location))&&(void 0===t.command||z.is(t.command))},(At=Ct||(Ct={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},At.is=function(e){const t=e;return Ut.objectLiteral(t)&&b.is(t.position)&&(Ut.string(t.label)||Ut.typedArray(t.label,It.is))&&(void 0===t.kind||wt.is(t.kind))&&void 0===t.textEdits||Ut.typedArray(t.textEdits,B.is)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.paddingLeft||Ut.boolean(t.paddingLeft))&&(void 0===t.paddingRight||Ut.boolean(t.paddingRight))},(St||(St={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Rt||(Rt={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},(Lt||(Lt={})).create=function(e){return{items:e}},(Mt=Tt||(Tt={})).Invoked=0,Mt.Automatic=1,(Dt||(Dt={})).create=function(e,t){return{range:e,text:t}},(Pt||(Pt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(Ft||(Ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&f.is(t.uri)&&Ut.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),o=e.slice(r);t(i,n),t(o,n);let a=0,s=0,u=0;for(;a{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),o=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],a=e.offsetAt(n.range.start),s=e.offsetAt(n.range.end);if(!(s<=o))throw new Error("Overlapping edit");r=r.substring(0,a)+n.newText+r.substring(s,r.length),o=a}return r}}(jt||(jt={}));var Ut,Vt=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return b.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return b.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1{let t,n=e.getLanguageId();n===this._languageId&&(this._listener[e.uri.toString()]=e.onDidChangeContent((()=>{window.clearTimeout(t),t=window.setTimeout((()=>this._doValidate(e.uri,n)),500)})),this._doValidate(e.uri,n))},i=e=>{l.editor.setModelMarkers(e,this._languageId,[]);let t=e.uri.toString(),n=this._listener[t];n&&(n.dispose(),delete this._listener[t])};this._disposables.push(l.editor.onDidCreateModel(r)),this._disposables.push(l.editor.onWillDisposeModel(i)),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{i(e.model),r(e.model)}))),this._disposables.push(n((e=>{l.editor.getModels().forEach((e=>{e.getLanguageId()===this._languageId&&(i(e),r(e))}))}))),this._disposables.push({dispose:()=>{l.editor.getModels().forEach(i);for(let e in this._listener)this._listener[e].dispose()}}),l.editor.getModels().forEach(r)}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables.length=0}_doValidate(e,t){this._worker(e).then((t=>t.doValidation(e.toString()))).then((n=>{const r=n.map((e=>function(e,t){let n="number"===typeof t.code?String(t.code):t.code;return{severity:Kt(t.severity),startLineNumber:t.range.start.line+1,startColumn:t.range.start.character+1,endLineNumber:t.range.end.line+1,endColumn:t.range.end.character+1,message:t.message,code:n,source:t.source}}(0,e)));let i=l.editor.getModel(e);i&&i.getLanguageId()===t&&l.editor.setModelMarkers(i,t,r)})).then(void 0,(e=>{console.error(e)}))}};function Kt(e){switch(e){case U.Error:return l.MarkerSeverity.Error;case U.Warning:return l.MarkerSeverity.Warning;case U.Information:return l.MarkerSeverity.Info;case U.Hint:return l.MarkerSeverity.Hint;default:return l.MarkerSeverity.Info}}var Wt=class{constructor(e,t){this._worker=e,this._triggerCharacters=t}get triggerCharacters(){return this._triggerCharacters}provideCompletionItems(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doComplete(i.toString(),Ht(t)))).then((n=>{if(!n)return;const r=e.getWordUntilPosition(t),i=new l.Range(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn),o=n.items.map((e=>{const t={label:e.label,insertText:e.insertText||e.label,sortText:e.sortText,filterText:e.filterText,documentation:e.documentation,detail:e.detail,command:(n=e.command,n&&"editor.action.triggerSuggest"===n.command?{id:n.command,title:n.title,arguments:n.arguments}:void 0),range:i,kind:$t(e.kind)};var n,r;return e.textEdit&&("undefined"!==typeof(r=e.textEdit).insert&&"undefined"!==typeof r.replace?t.range={insert:zt(e.textEdit.insert),replace:zt(e.textEdit.replace)}:t.range=zt(e.textEdit.range),t.insertText=e.textEdit.newText),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),e.insertTextFormat===we.Snippet&&(t.insertTextRules=l.languages.CompletionItemInsertTextRule.InsertAsSnippet),t}));return{isIncomplete:n.isIncomplete,suggestions:o}}))}};function Ht(e){if(e)return{character:e.column-1,line:e.lineNumber-1}}function Xt(e){if(e)return{start:{line:e.startLineNumber-1,character:e.startColumn-1},end:{line:e.endLineNumber-1,character:e.endColumn-1}}}function zt(e){if(e)return new l.Range(e.start.line+1,e.start.character+1,e.end.line+1,e.end.character+1)}function $t(e){const t=l.languages.CompletionItemKind;switch(e){case ke.Text:return t.Text;case ke.Method:return t.Method;case ke.Function:return t.Function;case ke.Constructor:return t.Constructor;case ke.Field:return t.Field;case ke.Variable:return t.Variable;case ke.Class:return t.Class;case ke.Interface:return t.Interface;case ke.Module:return t.Module;case ke.Property:return t.Property;case ke.Unit:return t.Unit;case ke.Value:return t.Value;case ke.Enum:return t.Enum;case ke.Keyword:return t.Keyword;case ke.Snippet:return t.Snippet;case ke.Color:return t.Color;case ke.File:return t.File;case ke.Reference:return t.Reference}return t.Property}function Bt(e){if(e)return{range:zt(e.range),text:e.newText}}var qt=class{constructor(e){this._worker=e}provideHover(e,t,n){let r=e.uri;return this._worker(r).then((e=>e.doHover(r.toString(),Ht(t)))).then((e=>{if(e)return{range:zt(e.range),contents:Gt(e.contents)}}))}};function Qt(e){return"string"===typeof e?{value:e}:(t=e)&&"object"===typeof t&&"string"===typeof t.kind?"plaintext"===e.kind?{value:e.value.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}:{value:e.value}:{value:"```"+e.language+"\n"+e.value+"\n```\n"};var t}function Gt(e){if(e)return Array.isArray(e)?e.map(Qt):[Qt(e)]}var Jt=class{constructor(e){this._worker=e}provideDocumentHighlights(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDocumentHighlights(r.toString(),Ht(t)))).then((e=>{if(e)return e.map((e=>({range:zt(e.range),kind:Yt(e.kind)})))}))}};function Yt(e){switch(e){case Ne.Read:return l.languages.DocumentHighlightKind.Read;case Ne.Write:return l.languages.DocumentHighlightKind.Write;case Ne.Text:return l.languages.DocumentHighlightKind.Text}return l.languages.DocumentHighlightKind.Text}var Zt=class{constructor(e){this._worker=e}provideDefinition(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDefinition(r.toString(),Ht(t)))).then((e=>{if(e)return[en(e)]}))}};function en(e){return{uri:l.Uri.parse(e.uri),range:zt(e.range)}}var tn=class{constructor(e){this._worker=e}provideReferences(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.findReferences(i.toString(),Ht(t)))).then((e=>{if(e)return e.map(en)}))}},nn=class{constructor(e){this._worker=e}provideRenameEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doRename(i.toString(),Ht(t),n))).then((e=>function(e){if(!e||!e.changes)return;let t=[];for(let n in e.changes){const r=l.Uri.parse(n);for(let i of e.changes[n])t.push({resource:r,versionId:void 0,textEdit:{range:zt(i.range),text:i.newText}})}return{edits:t}}(e)))}};var rn=class{constructor(e){this._worker=e}provideDocumentSymbols(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentSymbols(n.toString()))).then((e=>{if(e)return e.map((e=>"children"in e?on(e):{name:e.name,detail:"",containerName:e.containerName,kind:an(e.kind),range:zt(e.location.range),selectionRange:zt(e.location.range),tags:[]}))}))}};function on(e){return{name:e.name,detail:e.detail??"",kind:an(e.kind),range:zt(e.range),selectionRange:zt(e.selectionRange),tags:e.tags??[],children:(e.children??[]).map((e=>on(e)))}}function an(e){let t=l.languages.SymbolKind;switch(e){case Oe.File:return t.File;case Oe.Module:return t.Module;case Oe.Namespace:return t.Namespace;case Oe.Package:return t.Package;case Oe.Class:return t.Class;case Oe.Method:return t.Method;case Oe.Property:return t.Property;case Oe.Field:return t.Field;case Oe.Constructor:return t.Constructor;case Oe.Enum:return t.Enum;case Oe.Interface:return t.Interface;case Oe.Function:return t.Function;case Oe.Variable:return t.Variable;case Oe.Constant:return t.Constant;case Oe.String:return t.String;case Oe.Number:return t.Number;case Oe.Boolean:return t.Boolean;case Oe.Array:return t.Array}return t.Function}var sn=class{constructor(e){this._worker=e}provideLinks(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentLinks(n.toString()))).then((e=>{if(e)return{links:e.map((e=>({range:zt(e.range),url:e.target})))}}))}},un=class{constructor(e){this._worker=e}provideDocumentFormattingEdits(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.format(r.toString(),null,dn(t)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}},cn=class{constructor(e){this._worker=e,this.canFormatMultipleRanges=!1}provideDocumentRangeFormattingEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.format(i.toString(),Xt(t),dn(n)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}};function dn(e){return{tabSize:e.tabSize,insertSpaces:e.insertSpaces}}var ln=class{constructor(e){this._worker=e}provideDocumentColors(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentColors(n.toString()))).then((e=>{if(e)return e.map((e=>({color:e.color,range:zt(e.range)})))}))}provideColorPresentations(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getColorPresentations(r.toString(),t.color,Xt(t.range)))).then((e=>{if(e)return e.map((e=>{let t={label:e.label};return e.textEdit&&(t.textEdit=Bt(e.textEdit)),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),t}))}))}},gn=class{constructor(e){this._worker=e}provideFoldingRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getFoldingRanges(r.toString(),t))).then((e=>{if(e)return e.map((e=>{const t={start:e.startLine+1,end:e.endLine+1};return"undefined"!==typeof e.kind&&(t.kind=function(e){switch(e){case M.Comment:return l.languages.FoldingRangeKind.Comment;case M.Imports:return l.languages.FoldingRangeKind.Imports;case M.Region:return l.languages.FoldingRangeKind.Region}return}(e.kind)),t}))}))}};var fn=class{constructor(e){this._worker=e}provideSelectionRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getSelectionRanges(r.toString(),t.map(Ht)))).then((e=>{if(e)return e.map((e=>{const t=[];for(;e;)t.push({range:zt(e.range)}),e=e.parent;return t}))}))}};function hn(e){const t=[],n=[],r=new Nt(e);t.push(r);const i=(...e)=>r.getLanguageServiceWorker(...e);return function(){const{languageId:t,modeConfiguration:r}=e;mn(n),r.completionItems&&n.push(l.languages.registerCompletionItemProvider(t,new Wt(i,["/","-",":"]))),r.hovers&&n.push(l.languages.registerHoverProvider(t,new qt(i))),r.documentHighlights&&n.push(l.languages.registerDocumentHighlightProvider(t,new Jt(i))),r.definitions&&n.push(l.languages.registerDefinitionProvider(t,new Zt(i))),r.references&&n.push(l.languages.registerReferenceProvider(t,new tn(i))),r.documentSymbols&&n.push(l.languages.registerDocumentSymbolProvider(t,new rn(i))),r.rename&&n.push(l.languages.registerRenameProvider(t,new nn(i))),r.colors&&n.push(l.languages.registerColorProvider(t,new ln(i))),r.foldingRanges&&n.push(l.languages.registerFoldingRangeProvider(t,new gn(i))),r.diagnostics&&n.push(new Ot(t,i,e.onDidChange)),r.selectionRanges&&n.push(l.languages.registerSelectionRangeProvider(t,new fn(i))),r.documentFormattingEdits&&n.push(l.languages.registerDocumentFormattingEditProvider(t,new un(i))),r.documentRangeFormattingEdits&&n.push(l.languages.registerDocumentRangeFormattingEditProvider(t,new cn(i)))}(),t.push(pn(n)),pn(t)}function pn(e){return{dispose:()=>mn(e)}}function mn(e){for(;e.length;)e.pop().dispose()}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7574.8ac9803d.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/70225.f064b5ad.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/7574.8ac9803d.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/70225.f064b5ad.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/70289.b63d5fb8.chunk.js b/ydb/core/viewer/monitoring/static/js/70289.b63d5fb8.chunk.js new file mode 100644 index 000000000000..c263ef9bfb42 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/70289.b63d5fb8.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[70289],{70289:(a,s,e)=>{e.d(s,{default:()=>l});const l=["abap","abnf","actionscript","ada","agda","al","antlr4","apacheconf","apex","apl","applescript","aql","arduino","arff","asciidoc","asm6502","asmatmel","aspnet","autohotkey","autoit","avisynth","avro-idl","bash","basic","batch","bbcode","bicep","birb","bison","bnf","brainfuck","brightscript","bro","bsl","c","cfscript","chaiscript","cil","clike","clojure","cmake","cobol","coffeescript","concurnas","coq","cpp","crystal","csharp","cshtml","csp","css-extras","css","csv","cypher","d","dart","dataweave","dax","dhall","diff","django","dns-zone-file","docker","dot","ebnf","editorconfig","eiffel","ejs","elixir","elm","erb","erlang","etlua","excel-formula","factor","false","firestore-security-rules","flow","fortran","fsharp","ftl","gap","gcode","gdscript","gedcom","gherkin","git","glsl","gml","gn","go-module","go","graphql","groovy","haml","handlebars","haskell","haxe","hcl","hlsl","hoon","hpkp","hsts","http","ichigojam","icon","icu-message-format","idris","iecst","ignore","inform7","ini","io","j","java","javadoc","javadoclike","javascript","javastacktrace","jexl","jolie","jq","js-extras","js-templates","jsdoc","json","json5","jsonp","jsstacktrace","jsx","julia","keepalived","keyman","kotlin","kumir","kusto","latex","latte","less","lilypond","liquid","lisp","livescript","llvm","log","lolcode","lua","magma","makefile","markdown","markup-templating","markup","matlab","maxscript","mel","mermaid","mizar","mongodb","monkey","moonscript","n1ql","n4js","nand2tetris-hdl","naniscript","nasm","neon","nevod","nginx","nim","nix","nsis","objectivec","ocaml","opencl","openqasm","oz","parigp","parser","pascal","pascaligo","pcaxis","peoplecode","perl","php-extras","php","phpdoc","plsql","powerquery","powershell","processing","prolog","promql","properties","protobuf","psl","pug","puppet","pure","purebasic","purescript","python","q","qml","qore","qsharp","r","racket","reason","regex","rego","renpy","rest","rip","roboconf","robotframework","ruby","rust","sas","sass","scala","scheme","scss","shell-session","smali","smalltalk","smarty","sml","solidity","solution-file","soy","sparql","splunk-spl","sqf","sql","squirrel","stan","stylus","swift","systemd","t4-cs","t4-templating","t4-vb","tap","tcl","textile","toml","tremor","tsx","tt2","turtle","twig","typescript","typoscript","unrealscript","uorazor","uri","v","vala","vbnet","velocity","verilog","vhdl","vim","visual-basic","warpscript","wasm","web-idl","wiki","wolfram","wren","xeora","xml-doc","xojo","xquery","yaml","yang","zig"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/70695.3af812a3.chunk.js b/ydb/core/viewer/monitoring/static/js/70695.3af812a3.chunk.js new file mode 100644 index 000000000000..d93e7d9e5fad --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/70695.3af812a3.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[70695],{70586:e=>{function t(e){e.languages.turtle={comment:{pattern:/#.*/,greedy:!0},"multiline-string":{pattern:/"""(?:(?:""?)?(?:[^"\\]|\\.))*"""|'''(?:(?:''?)?(?:[^'\\]|\\.))*'''/,greedy:!0,alias:"string",inside:{comment:/#.*/}},string:{pattern:/"(?:[^\\"\r\n]|\\.)*"|'(?:[^\\'\r\n]|\\.)*'/,greedy:!0},url:{pattern:/<(?:[^\x00-\x20<>"{}|^`\\]|\\(?:u[\da-fA-F]{4}|U[\da-fA-F]{8}))*>/,greedy:!0,inside:{punctuation:/[<>]/}},function:{pattern:/(?:(?![-.\d\xB7])[-.\w\xB7\xC0-\uFFFD]+)?:(?:(?![-.])(?:[-.:\w\xC0-\uFFFD]|%[\da-f]{2}|\\.)+)?/i,inside:{"local-name":{pattern:/([^:]*:)[\s\S]+/,lookbehind:!0},prefix:{pattern:/[\s\S]+/,inside:{punctuation:/:/}}}},number:/[+-]?\b\d+(?:\.\d*)?(?:e[+-]?\d+)?/i,punctuation:/[{}.,;()[\]]|\^\^/,boolean:/\b(?:false|true)\b/,keyword:[/(?:\ba|@prefix|@base)\b|=/,/\b(?:base|graph|prefix)\b/i],tag:{pattern:/@[a-z]+(?:-[a-z\d]+)*/i,inside:{punctuation:/@/}}},e.languages.trig=e.languages.turtle}e.exports=t,t.displayName="turtle",t.aliases=[]},70695:(e,t,a)=>{a.d(t,{default:()=>i});var n=a(70586);const i=a.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/70858.35d686d1.chunk.js b/ydb/core/viewer/monitoring/static/js/70858.35d686d1.chunk.js new file mode 100644 index 000000000000..4da7e75b7c3d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/70858.35d686d1.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[70858],{50621:e=>{function d(e){e.languages.rip={comment:{pattern:/#.*/,greedy:!0},char:{pattern:/\B`[^\s`'",.:;#\/\\()<>\[\]{}]\b/,greedy:!0},string:{pattern:/("|')(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0},regex:{pattern:/(^|[^/])\/(?!\/)(?:\[[^\n\r\]]*\]|\\.|[^/\\\r\n\[])+\/(?=\s*(?:$|[\r\n,.;})]))/,lookbehind:!0,greedy:!0},keyword:/(?:=>|->)|\b(?:case|catch|class|else|exit|finally|if|raise|return|switch|try)\b/,builtin:/@|\bSystem\b/,boolean:/\b(?:false|true)\b/,date:/\b\d{4}-\d{2}-\d{2}\b/,time:/\b\d{2}:\d{2}:\d{2}\b/,datetime:/\b\d{4}-\d{2}-\d{2}T\d{2}:\d{2}:\d{2}\b/,symbol:/:[^\d\s`'",.:;#\/\\()<>\[\]{}][^\s`'",.:;#\/\\()<>\[\]{}]*/,number:/[+-]?\b(?:\d+\.\d+|\d+)\b/,punctuation:/(?:\.{2,3})|[`,.:;=\/\\()<>\[\]{}]/,reference:/[^\d\s`'",.:;#\/\\()<>\[\]{}][^\s`'",.:;#\/\\()<>\[\]{}]*/}}e.exports=d,d.displayName="rip",d.aliases=[]},70858:(e,d,t)=>{t.d(d,{default:()=>b});var r=t(50621);const b=t.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/710.87e9f2e0.chunk.js b/ydb/core/viewer/monitoring/static/js/710.87e9f2e0.chunk.js deleted file mode 100644 index 7a72cc998963..000000000000 --- a/ydb/core/viewer/monitoring/static/js/710.87e9f2e0.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[710],{40710:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"uz",weekdays:"\u042f\u043a\u0448\u0430\u043d\u0431\u0430_\u0414\u0443\u0448\u0430\u043d\u0431\u0430_\u0421\u0435\u0448\u0430\u043d\u0431\u0430_\u0427\u043e\u0440\u0448\u0430\u043d\u0431\u0430_\u041f\u0430\u0439\u0448\u0430\u043d\u0431\u0430_\u0416\u0443\u043c\u0430_\u0428\u0430\u043d\u0431\u0430".split("_"),months:"\u044f\u043d\u0432\u0430\u0440_\u0444\u0435\u0432\u0440\u0430\u043b_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0435\u043b_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043d\u0442\u044f\u0431\u0440_\u043e\u043a\u0442\u044f\u0431\u0440_\u043d\u043e\u044f\u0431\u0440_\u0434\u0435\u043a\u0430\u0431\u0440".split("_"),weekStart:1,weekdaysShort:"\u042f\u043a\u0448_\u0414\u0443\u0448_\u0421\u0435\u0448_\u0427\u043e\u0440_\u041f\u0430\u0439_\u0416\u0443\u043c_\u0428\u0430\u043d".split("_"),monthsShort:"\u044f\u043d\u0432_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433_\u0441\u0435\u043d_\u043e\u043a\u0442_\u043d\u043e\u044f_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u042f\u043a_\u0414\u0443_\u0421\u0435_\u0427\u043e_\u041f\u0430_\u0416\u0443_\u0428\u0430".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"D MMMM YYYY, dddd HH:mm"},relativeTime:{future:"\u042f\u043a\u0438\u043d %s \u0438\u0447\u0438\u0434\u0430",past:"%s \u043e\u043b\u0434\u0438\u043d",s:"\u0444\u0443\u0440\u0441\u0430\u0442",m:"\u0431\u0438\u0440 \u0434\u0430\u043a\u0438\u043a\u0430",mm:"%d \u0434\u0430\u043a\u0438\u043a\u0430",h:"\u0431\u0438\u0440 \u0441\u043e\u0430\u0442",hh:"%d \u0441\u043e\u0430\u0442",d:"\u0431\u0438\u0440 \u043a\u0443\u043d",dd:"%d \u043a\u0443\u043d",M:"\u0431\u0438\u0440 \u043e\u0439",MM:"%d \u043e\u0439",y:"\u0431\u0438\u0440 \u0439\u0438\u043b",yy:"%d \u0439\u0438\u043b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71107.d2d26409.chunk.js b/ydb/core/viewer/monitoring/static/js/71107.d2d26409.chunk.js new file mode 100644 index 000000000000..930239031b2f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71107.d2d26409.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71107],{51498:e=>{function a(e){!function(e){e.languages.sass=e.languages.extend("css",{comment:{pattern:/^([ \t]*)\/[\/*].*(?:(?:\r?\n|\r)\1[ \t].+)*/m,lookbehind:!0,greedy:!0}}),e.languages.insertBefore("sass","atrule",{"atrule-line":{pattern:/^(?:[ \t]*)[@+=].+/m,greedy:!0,inside:{atrule:/(?:@[\w-]+|[+=])/}}}),delete e.languages.sass.atrule;var a=/\$[-\w]+|#\{\$[-\w]+\}/,s=[/[+*\/%]|[=!]=|<=?|>=?|\b(?:and|not|or)\b/,{pattern:/(\s)-(?=\s)/,lookbehind:!0}];e.languages.insertBefore("sass","property",{"variable-line":{pattern:/^[ \t]*\$.+/m,greedy:!0,inside:{punctuation:/:/,variable:a,operator:s}},"property-line":{pattern:/^[ \t]*(?:[^:\s]+ *:.*|:[^:\s].*)/m,greedy:!0,inside:{property:[/[^:\s]+(?=\s*:)/,{pattern:/(:)[^:\s]+/,lookbehind:!0}],punctuation:/:/,variable:a,operator:s,important:e.languages.sass.important}}}),delete e.languages.sass.property,delete e.languages.sass.important,e.languages.insertBefore("sass","punctuation",{selector:{pattern:/^([ \t]*)\S(?:,[^,\r\n]+|[^,\r\n]*)(?:,[^,\r\n]+)*(?:,(?:\r?\n|\r)\1[ \t]+\S(?:,[^,\r\n]+|[^,\r\n]*)(?:,[^,\r\n]+)*)*/m,lookbehind:!0,greedy:!0}})}(e)}e.exports=a,a.displayName="sass",a.aliases=[]},71107:(e,a,s)=>{s.d(a,{default:()=>n});var t=s(51498);const n=s.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7118.ce0cd05f.chunk.js b/ydb/core/viewer/monitoring/static/js/7118.ce0cd05f.chunk.js deleted file mode 100644 index 3e98dfae0e75..000000000000 --- a/ydb/core/viewer/monitoring/static/js/7118.ce0cd05f.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 7118.ce0cd05f.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[7118],{57118:(e,o,n)=>{n.r(o),n.d(o,{conf:()=>t,language:()=>s});var t={comments:{lineComment:"//",blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:"'",close:"'"}]},s={defaultToken:"",tokenPostfix:".pascaligo",ignoreCase:!0,brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],keywords:["begin","block","case","const","else","end","fail","for","from","function","if","is","nil","of","remove","return","skip","then","type","var","while","with","option","None","transaction"],typeKeywords:["bool","int","list","map","nat","record","string","unit","address","map","mtz","xtz"],operators:["=",">","<","<=",">=","<>",":",":=","and","mod","or","+","-","*","/","@","&","^","%"],symbols:/[=><:@\^&|+\-*\/\^%]+/,tokenizer:{root:[[/[a-zA-Z_][\w]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[<>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\$[0-9a-fA-F]{1,16}/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"],[/'([^'\\]|\\.)*$/,"string.invalid"],[/'/,"string","@string"],[/'[^\\']'/,"string"],[/'/,"string.invalid"],[/\#\d+/,"string"]],comment:[[/[^\(\*]+/,"comment"],[/\*\)/,"comment","@pop"],[/\(\*/,"comment"]],string:[[/[^\\']+/,"string"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"],[/\(\*/,"comment","@comment"],[/\/\/.*$/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71266.6ba99b0a.chunk.js b/ydb/core/viewer/monitoring/static/js/71266.6ba99b0a.chunk.js new file mode 100644 index 000000000000..46e31182cea7 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71266.6ba99b0a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71266],{71266:(e,a,t)=>{t.d(a,{default:()=>n});var i=t(82087);const n=t.n(i)()},82087:e=>{function a(e){e.languages.editorconfig={comment:/[;#].*/,section:{pattern:/(^[ \t]*)\[.+\]/m,lookbehind:!0,alias:"selector",inside:{regex:/\\\\[\[\]{},!?.*]/,operator:/[!?]|\.\.|\*{1,2}/,punctuation:/[\[\]{},]/}},key:{pattern:/(^[ \t]*)[^\s=]+(?=[ \t]*=)/m,lookbehind:!0,alias:"attr-name"},value:{pattern:/=.*/,alias:"attr-value",inside:{punctuation:/^=/}}}}e.exports=a,a.displayName="editorconfig",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7148.ef54cd41.chunk.js b/ydb/core/viewer/monitoring/static/js/7148.ef54cd41.chunk.js deleted file mode 100644 index e23ff7ae6ef0..000000000000 --- a/ydb/core/viewer/monitoring/static/js/7148.ef54cd41.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 7148.ef54cd41.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[7148],{27148:(e,n,o)=>{o.r(n),o.d(n,{conf:()=>t,language:()=>s});var t={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"`",close:"`",notIn:["string"]},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string","comment"]}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"`",close:"`"},{open:'"',close:'"'},{open:"'",close:"'"}]},s={defaultToken:"",tokenPostfix:".go",keywords:["break","case","chan","const","continue","default","defer","else","fallthrough","for","func","go","goto","if","import","interface","map","package","range","return","select","struct","switch","type","var","bool","true","false","uint8","uint16","uint32","uint64","int8","int16","int32","int64","float32","float64","complex64","complex128","byte","rune","uint","int","uintptr","string","nil"],operators:["+","-","*","/","%","&","|","^","<<",">>","&^","+=","-=","*=","/=","%=","&=","|=","^=","<<=",">>=","&^=","&&","||","<-","++","--","==","<",">","=","!","!=","<=",">=",":=","...","(",")","","]","{","}",",",";",".",":"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F]/,"number.hex"],[/0[0-7']*[0-7]/,"number.octal"],[/0[bB][0-1']*[0-1]/,"number.binary"],[/\d[\d']*/,"number"],[/\d/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/`/,"string","@rawstring"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\/\*/,"comment.doc.invalid"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],rawstring:[[/[^\`]/,"string"],[/`/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71486.3e01f058.chunk.js b/ydb/core/viewer/monitoring/static/js/71486.3e01f058.chunk.js new file mode 100644 index 000000000000..b9db54d940d4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71486.3e01f058.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71486],{71486:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"sd",weekdays:"\u0622\u0686\u0631_\u0633\u0648\u0645\u0631_\u0627\u06b1\u0627\u0631\u0648_\u0627\u0631\u0628\u0639_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639_\u0687\u0646\u0687\u0631".split("_"),months:"\u062c\u0646\u0648\u0631\u064a_\u0641\u064a\u0628\u0631\u0648\u0631\u064a_\u0645\u0627\u0631\u0686_\u0627\u067e\u0631\u064a\u0644_\u0645\u0626\u064a_\u062c\u0648\u0646_\u062c\u0648\u0644\u0627\u0621\u0650_\u0622\u06af\u0633\u067d_\u0633\u064a\u067e\u067d\u0645\u0628\u0631_\u0622\u06aa\u067d\u0648\u0628\u0631_\u0646\u0648\u0645\u0628\u0631_\u068a\u0633\u0645\u0628\u0631".split("_"),weekStart:1,weekdaysShort:"\u0622\u0686\u0631_\u0633\u0648\u0645\u0631_\u0627\u06b1\u0627\u0631\u0648_\u0627\u0631\u0628\u0639_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639_\u0687\u0646\u0687\u0631".split("_"),monthsShort:"\u062c\u0646\u0648\u0631\u064a_\u0641\u064a\u0628\u0631\u0648\u0631\u064a_\u0645\u0627\u0631\u0686_\u0627\u067e\u0631\u064a\u0644_\u0645\u0626\u064a_\u062c\u0648\u0646_\u062c\u0648\u0644\u0627\u0621\u0650_\u0622\u06af\u0633\u067d_\u0633\u064a\u067e\u067d\u0645\u0628\u0631_\u0622\u06aa\u067d\u0648\u0628\u0631_\u0646\u0648\u0645\u0628\u0631_\u068a\u0633\u0645\u0628\u0631".split("_"),weekdaysMin:"\u0622\u0686\u0631_\u0633\u0648\u0645\u0631_\u0627\u06b1\u0627\u0631\u0648_\u0627\u0631\u0628\u0639_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639_\u0687\u0646\u0687\u0631".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd\u060c D MMMM YYYY HH:mm"},relativeTime:{future:"%s \u067e\u0648\u0621",past:"%s \u0627\u06b3",s:"\u0686\u0646\u062f \u0633\u064a\u06aa\u0646\u068a",m:"\u0647\u06aa \u0645\u0646\u067d",mm:"%d \u0645\u0646\u067d",h:"\u0647\u06aa \u06aa\u0644\u0627\u06aa",hh:"%d \u06aa\u0644\u0627\u06aa",d:"\u0647\u06aa \u068f\u064a\u0646\u0647\u0646",dd:"%d \u068f\u064a\u0646\u0647\u0646",M:"\u0647\u06aa \u0645\u0647\u064a\u0646\u0648",MM:"%d \u0645\u0647\u064a\u0646\u0627",y:"\u0647\u06aa \u0633\u0627\u0644",yy:"%d \u0633\u0627\u0644"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71515.2280d42d.chunk.js b/ydb/core/viewer/monitoring/static/js/71515.2280d42d.chunk.js new file mode 100644 index 000000000000..2f47861cf84c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71515.2280d42d.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71515],{71515:(e,n,d)=>{d.d(n,{default:()=>t});var a=d(76064);const t=d.n(a)()},76064:e=>{function n(e){e.languages.lua={comment:/^#!.+|--(?:\[(=*)\[[\s\S]*?\]\1\]|.*)/m,string:{pattern:/(["'])(?:(?!\1)[^\\\r\n]|\\z(?:\r\n|\s)|\\(?:\r\n|[^z]))*\1|\[(=*)\[[\s\S]*?\]\2\]/,greedy:!0},number:/\b0x[a-f\d]+(?:\.[a-f\d]*)?(?:p[+-]?\d+)?\b|\b\d+(?:\.\B|(?:\.\d*)?(?:e[+-]?\d+)?\b)|\B\.\d+(?:e[+-]?\d+)?\b/i,keyword:/\b(?:and|break|do|else|elseif|end|false|for|function|goto|if|in|local|nil|not|or|repeat|return|then|true|until|while)\b/,function:/(?!\d)\w+(?=\s*(?:[({]))/,operator:[/[-+*%^&|#]|\/\/?|<[<=]?|>[>=]?|[=~]=?/,{pattern:/(^|[^.])\.\.(?!\.)/,lookbehind:!0}],punctuation:/[\[\](){},;]|\.+|:+/}}e.exports=n,n.displayName="lua",n.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71588.5c21e822.chunk.js b/ydb/core/viewer/monitoring/static/js/71588.5c21e822.chunk.js new file mode 100644 index 000000000000..819e3fd07bf0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71588.5c21e822.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71588],{68987:n=>{function t(n){n.languages.graphql={comment:/#.*/,description:{pattern:/(?:"""(?:[^"]|(?!""")")*"""|"(?:\\.|[^\\"\r\n])*")(?=\s*[a-z_])/i,greedy:!0,alias:"string",inside:{"language-markdown":{pattern:/(^"(?:"")?)(?!\1)[\s\S]+(?=\1$)/,lookbehind:!0,inside:n.languages.markdown}}},string:{pattern:/"""(?:[^"]|(?!""")")*"""|"(?:\\.|[^\\"\r\n])*"/,greedy:!0},number:/(?:\B-|\b)\d+(?:\.\d+)?(?:e[+-]?\d+)?\b/i,boolean:/\b(?:false|true)\b/,variable:/\$[a-z_]\w*/i,directive:{pattern:/@[a-z_]\w*/i,alias:"function"},"attr-name":{pattern:/\b[a-z_]\w*(?=\s*(?:\((?:[^()"]|"(?:\\.|[^\\"\r\n])*")*\))?:)/i,greedy:!0},"atom-input":{pattern:/\b[A-Z]\w*Input\b/,alias:"class-name"},scalar:/\b(?:Boolean|Float|ID|Int|String)\b/,constant:/\b[A-Z][A-Z_\d]*\b/,"class-name":{pattern:/(\b(?:enum|implements|interface|on|scalar|type|union)\s+|&\s*|:\s*|\[)[A-Z_]\w*/,lookbehind:!0},fragment:{pattern:/(\bfragment\s+|\.{3}\s*(?!on\b))[a-zA-Z_]\w*/,lookbehind:!0,alias:"function"},"definition-mutation":{pattern:/(\bmutation\s+)[a-zA-Z_]\w*/,lookbehind:!0,alias:"function"},"definition-query":{pattern:/(\bquery\s+)[a-zA-Z_]\w*/,lookbehind:!0,alias:"function"},keyword:/\b(?:directive|enum|extend|fragment|implements|input|interface|mutation|on|query|repeatable|scalar|schema|subscription|type|union)\b/,operator:/[!=|&]|\.{3}/,"property-query":/\w+(?=\s*\()/,object:/\w+(?=\s*\{)/,punctuation:/[!(){}\[\]:=,]/,property:/\w+/},n.hooks.add("after-tokenize",(function(n){if("graphql"===n.language)for(var t=n.tokens.filter((function(n){return"string"!==typeof n&&"comment"!==n.type&&"scalar"!==n.type})),e=0;e0)){var s=b(/^\{$/,/^\}$/);if(-1===s)continue;for(var u=e;u=0&&f(p,"variable-input")}}}}function l(n){return t[e+n]}function c(n,t){t=t||0;for(var e=0;e{e.d(t,{default:()=>i});var a=e(68987);const i=e.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71672.9d9a091b.chunk.js b/ydb/core/viewer/monitoring/static/js/71672.9d9a091b.chunk.js new file mode 100644 index 000000000000..37527978e618 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71672.9d9a091b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71672],{37260:e=>{function s(e){!function(e){function s(e,s,n){return{pattern:RegExp("<#"+e+"[\\s\\S]*?#>"),alias:"block",inside:{delimiter:{pattern:RegExp("^<#"+e+"|#>$"),alias:"important"},content:{pattern:/[\s\S]+/,inside:s,alias:n}}}}e.languages["t4-templating"]=Object.defineProperty({},"createT4",{value:function(n){var r=e.languages[n],a="language-"+n;return{block:{pattern:/<#[\s\S]+?#>/,inside:{directive:s("@",{"attr-value":{pattern:/=(?:("|')(?:\\[\s\S]|(?!\1)[^\\])*\1|[^\s'">=]+)/,inside:{punctuation:/^=|^["']|["']$/}},keyword:/\b\w+(?=\s)/,"attr-name":/\b\w+/}),expression:s("=",r,a),"class-feature":s("\\+",r,a),standard:s("",r,a)}}}}})}(e)}e.exports=s,s.displayName="t4Templating",s.aliases=[]},71672:(e,s,n)=>{n.d(s,{default:()=>a});var r=n(96399);const a=n.n(r)()},90323:e=>{function s(e){!function(e){function s(e,s){return e.replace(/<<(\d+)>>/g,(function(e,n){return"(?:"+s[+n]+")"}))}function n(e,n,r){return RegExp(s(e,n),r||"")}function r(e,s){for(var n=0;n>/g,(function(){return"(?:"+e+")"}));return e.replace(/<>/g,"[^\\s\\S]")}var a="bool byte char decimal double dynamic float int long object sbyte short string uint ulong ushort var void",t="class enum interface record struct",i="add alias and ascending async await by descending from(?=\\s*(?:\\w|$)) get global group into init(?=\\s*;) join let nameof not notnull on or orderby partial remove select set unmanaged value when where with(?=\\s*{)",o="abstract as base break case catch checked const continue default delegate do else event explicit extern finally fixed for foreach goto if implicit in internal is lock namespace new null operator out override params private protected public readonly ref return sealed sizeof stackalloc static switch this throw try typeof unchecked unsafe using virtual volatile while yield";function u(e){return"\\b(?:"+e.trim().replace(/ /g,"|")+")\\b"}var c=u(t),l=RegExp(u(a+" "+t+" "+i+" "+o)),d=u(t+" "+i+" "+o),p=u(a+" "+t+" "+o),g=r(/<(?:[^<>;=+\-*/%&|^]|<>)*>/.source,2),b=r(/\((?:[^()]|<>)*\)/.source,2),h=/@?\b[A-Za-z_]\w*\b/.source,f=s(/<<0>>(?:\s*<<1>>)?/.source,[h,g]),m=s(/(?!<<0>>)<<1>>(?:\s*\.\s*<<1>>)*/.source,[d,f]),k=/\[\s*(?:,\s*)*\]/.source,y=s(/<<0>>(?:\s*(?:\?\s*)?<<1>>)*(?:\s*\?)?/.source,[m,k]),w=s(/[^,()<>[\];=+\-*/%&|^]|<<0>>|<<1>>|<<2>>/.source,[g,b,k]),v=s(/\(<<0>>+(?:,<<0>>+)+\)/.source,[w]),x=s(/(?:<<0>>|<<1>>)(?:\s*(?:\?\s*)?<<2>>)*(?:\s*\?)?/.source,[v,m,k]),$={keyword:l,punctuation:/[<>()?,.:[\]]/},_=/'(?:[^\r\n'\\]|\\.|\\[Uux][\da-fA-F]{1,8})'/.source,S=/"(?:\\.|[^\\"\r\n])*"/.source,E=/@"(?:""|\\[\s\S]|[^\\"])*"(?!")/.source;e.languages.csharp=e.languages.extend("clike",{string:[{pattern:n(/(^|[^$\\])<<0>>/.source,[E]),lookbehind:!0,greedy:!0},{pattern:n(/(^|[^@$\\])<<0>>/.source,[S]),lookbehind:!0,greedy:!0}],"class-name":[{pattern:n(/(\busing\s+static\s+)<<0>>(?=\s*;)/.source,[m]),lookbehind:!0,inside:$},{pattern:n(/(\busing\s+<<0>>\s*=\s*)<<1>>(?=\s*;)/.source,[h,x]),lookbehind:!0,inside:$},{pattern:n(/(\busing\s+)<<0>>(?=\s*=)/.source,[h]),lookbehind:!0},{pattern:n(/(\b<<0>>\s+)<<1>>/.source,[c,f]),lookbehind:!0,inside:$},{pattern:n(/(\bcatch\s*\(\s*)<<0>>/.source,[m]),lookbehind:!0,inside:$},{pattern:n(/(\bwhere\s+)<<0>>/.source,[h]),lookbehind:!0},{pattern:n(/(\b(?:is(?:\s+not)?|as)\s+)<<0>>/.source,[y]),lookbehind:!0,inside:$},{pattern:n(/\b<<0>>(?=\s+(?!<<1>>|with\s*\{)<<2>>(?:\s*[=,;:{)\]]|\s+(?:in|when)\b))/.source,[x,p,h]),inside:$}],keyword:l,number:/(?:\b0(?:x[\da-f_]*[\da-f]|b[01_]*[01])|(?:\B\.\d+(?:_+\d+)*|\b\d+(?:_+\d+)*(?:\.\d+(?:_+\d+)*)?)(?:e[-+]?\d+(?:_+\d+)*)?)(?:[dflmu]|lu|ul)?\b/i,operator:/>>=?|<<=?|[-=]>|([-+&|])\1|~|\?\?=?|[-+*/%&|^!=<>]=?/,punctuation:/\?\.?|::|[{}[\];(),.:]/}),e.languages.insertBefore("csharp","number",{range:{pattern:/\.\./,alias:"operator"}}),e.languages.insertBefore("csharp","punctuation",{"named-parameter":{pattern:n(/([(,]\s*)<<0>>(?=\s*:)/.source,[h]),lookbehind:!0,alias:"punctuation"}}),e.languages.insertBefore("csharp","class-name",{namespace:{pattern:n(/(\b(?:namespace|using)\s+)<<0>>(?:\s*\.\s*<<0>>)*(?=\s*[;{])/.source,[h]),lookbehind:!0,inside:{punctuation:/\./}},"type-expression":{pattern:n(/(\b(?:default|sizeof|typeof)\s*\(\s*(?!\s))(?:[^()\s]|\s(?!\s)|<<0>>)*(?=\s*\))/.source,[b]),lookbehind:!0,alias:"class-name",inside:$},"return-type":{pattern:n(/<<0>>(?=\s+(?:<<1>>\s*(?:=>|[({]|\.\s*this\s*\[)|this\s*\[))/.source,[x,m]),inside:$,alias:"class-name"},"constructor-invocation":{pattern:n(/(\bnew\s+)<<0>>(?=\s*[[({])/.source,[x]),lookbehind:!0,inside:$,alias:"class-name"},"generic-method":{pattern:n(/<<0>>\s*<<1>>(?=\s*\()/.source,[h,g]),inside:{function:n(/^<<0>>/.source,[h]),generic:{pattern:RegExp(g),alias:"class-name",inside:$}}},"type-list":{pattern:n(/\b((?:<<0>>\s+<<1>>|record\s+<<1>>\s*<<5>>|where\s+<<2>>)\s*:\s*)(?:<<3>>|<<4>>|<<1>>\s*<<5>>|<<6>>)(?:\s*,\s*(?:<<3>>|<<4>>|<<6>>))*(?=\s*(?:where|[{;]|=>|$))/.source,[c,f,h,x,l.source,b,/\bnew\s*\(\s*\)/.source]),lookbehind:!0,inside:{"record-arguments":{pattern:n(/(^(?!new\s*\()<<0>>\s*)<<1>>/.source,[f,b]),lookbehind:!0,greedy:!0,inside:e.languages.csharp},keyword:l,"class-name":{pattern:RegExp(x),greedy:!0,inside:$},punctuation:/[,()]/}},preprocessor:{pattern:/(^[\t ]*)#.*/m,lookbehind:!0,alias:"property",inside:{directive:{pattern:/(#)\b(?:define|elif|else|endif|endregion|error|if|line|nullable|pragma|region|undef|warning)\b/,lookbehind:!0,alias:"keyword"}}}});var R=S+"|"+_,B=s(/\/(?![*/])|\/\/[^\r\n]*[\r\n]|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>/.source,[R]),T=r(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[B]),2),j=/\b(?:assembly|event|field|method|module|param|property|return|type)\b/.source,z=s(/<<0>>(?:\s*\(<<1>>*\))?/.source,[m,T]);e.languages.insertBefore("csharp","class-name",{attribute:{pattern:n(/((?:^|[^\s\w>)?])\s*\[\s*)(?:<<0>>\s*:\s*)?<<1>>(?:\s*,\s*<<1>>)*(?=\s*\])/.source,[j,z]),lookbehind:!0,greedy:!0,inside:{target:{pattern:n(/^<<0>>(?=\s*:)/.source,[j]),alias:"keyword"},"attribute-arguments":{pattern:n(/\(<<0>>*\)/.source,[T]),inside:e.languages.csharp},"class-name":{pattern:RegExp(m),inside:{punctuation:/\./}},punctuation:/[:,]/}}});var C=/:[^}\r\n]+/.source,N=r(s(/[^"'/()]|<<0>>|\(<>*\)/.source,[B]),2),A=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[N,C]),F=r(s(/[^"'/()]|\/(?!\*)|\/\*(?:[^*]|\*(?!\/))*\*\/|<<0>>|\(<>*\)/.source,[R]),2),O=s(/\{(?!\{)(?:(?![}:])<<0>>)*<<1>>?\}/.source,[F,C]);function P(s,r){return{interpolation:{pattern:n(/((?:^|[^{])(?:\{\{)*)<<0>>/.source,[s]),lookbehind:!0,inside:{"format-string":{pattern:n(/(^\{(?:(?![}:])<<0>>)*)<<1>>(?=\}$)/.source,[r,C]),lookbehind:!0,inside:{punctuation:/^:/}},punctuation:/^\{|\}$/,expression:{pattern:/[\s\S]+/,alias:"language-csharp",inside:e.languages.csharp}}},string:/[\s\S]+/}}e.languages.insertBefore("csharp","string",{"interpolation-string":[{pattern:n(/(^|[^\\])(?:\$@|@\$)"(?:""|\\[\s\S]|\{\{|<<0>>|[^\\{"])*"/.source,[A]),lookbehind:!0,greedy:!0,inside:P(A,N)},{pattern:n(/(^|[^@\\])\$"(?:\\.|\{\{|<<0>>|[^\\"{])*"/.source,[O]),lookbehind:!0,greedy:!0,inside:P(O,F)}],char:{pattern:RegExp(_),greedy:!0}}),e.languages.dotnet=e.languages.cs=e.languages.csharp}(e)}e.exports=s,s.displayName="csharp",s.aliases=["dotnet","cs"]},96399:(e,s,n)=>{var r=n(37260),a=n(90323);function t(e){e.register(r),e.register(a),e.languages.t4=e.languages["t4-cs"]=e.languages["t4-templating"].createT4("csharp")}e.exports=t,t.displayName="t4Cs",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71756.324c49c8.chunk.js b/ydb/core/viewer/monitoring/static/js/71756.324c49c8.chunk.js new file mode 100644 index 000000000000..384ace44a27c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71756.324c49c8.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71756],{71756:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"tg",weekdays:"\u044f\u043a\u0448\u0430\u043d\u0431\u0435_\u0434\u0443\u0448\u0430\u043d\u0431\u0435_\u0441\u0435\u0448\u0430\u043d\u0431\u0435_\u0447\u043e\u0440\u0448\u0430\u043d\u0431\u0435_\u043f\u0430\u043d\u04b7\u0448\u0430\u043d\u0431\u0435_\u04b7\u0443\u043c\u044a\u0430_\u0448\u0430\u043d\u0431\u0435".split("_"),months:"\u044f\u043d\u0432\u0430\u0440_\u0444\u0435\u0432\u0440\u0430\u043b_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0435\u043b_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043d\u0442\u044f\u0431\u0440_\u043e\u043a\u0442\u044f\u0431\u0440_\u043d\u043e\u044f\u0431\u0440_\u0434\u0435\u043a\u0430\u0431\u0440".split("_"),weekStart:1,weekdaysShort:"\u044f\u0448\u0431_\u0434\u0448\u0431_\u0441\u0448\u0431_\u0447\u0448\u0431_\u043f\u0448\u0431_\u04b7\u0443\u043c_\u0448\u043d\u0431".split("_"),monthsShort:"\u044f\u043d\u0432_\u0444\u0435\u0432_\u043c\u0430\u0440_\u0430\u043f\u0440_\u043c\u0430\u0439_\u0438\u044e\u043d_\u0438\u044e\u043b_\u0430\u0432\u0433_\u0441\u0435\u043d_\u043e\u043a\u0442_\u043d\u043e\u044f_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u044f\u0448_\u0434\u0448_\u0441\u0448_\u0447\u0448_\u043f\u0448_\u04b7\u043c_\u0448\u0431".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"\u0431\u0430\u044a\u0434\u0438 %s",past:"%s \u043f\u0435\u0448",s:"\u044f\u043a\u0447\u0430\u043d\u0434 \u0441\u043e\u043d\u0438\u044f",m:"\u044f\u043a \u0434\u0430\u049b\u0438\u049b\u0430",mm:"%d \u0434\u0430\u049b\u0438\u049b\u0430",h:"\u044f\u043a \u0441\u043e\u0430\u0442",hh:"%d \u0441\u043e\u0430\u0442",d:"\u044f\u043a \u0440\u04ef\u0437",dd:"%d \u0440\u04ef\u0437",M:"\u044f\u043a \u043c\u043e\u04b3",MM:"%d \u043c\u043e\u04b3",y:"\u044f\u043a \u0441\u043e\u043b",yy:"%d \u0441\u043e\u043b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/71867.4808e834.chunk.js b/ydb/core/viewer/monitoring/static/js/71867.4808e834.chunk.js new file mode 100644 index 000000000000..6d499b4c8419 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/71867.4808e834.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[71867],{8873:(e,t,n)=>{n.d(t,{A:()=>i});var o=n(59284);const i=e=>o.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),o.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 0 1 6.445 5.649.75.75 0 1 1-1.488.194A5.001 5.001 0 0 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 1 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5m5.25 13a.75.75 0 0 0 .75-.75v-3a.75.75 0 0 0-.75-.75h-3a.75.75 0 1 0 0 1.5h1.32a5.001 5.001 0 0 1-8.528-2.843.75.75 0 1 0-1.487.194 6.501 6.501 0 0 0 10.945 3.84v1.059c0 .414.336.75.75.75",clipRule:"evenodd"}))},12640:(e,t,n)=>{n.d(t,{c:()=>m});var o=n(59284),i=n(14794),s=n(98392),r=n(27145),l=n(67459);var a=n(11507);const c=(0,n(69220).om)("sheet");class u{constructor(e,t){this.x=e,this.y=t,this.timeStamp=Date.now()}}class d{constructor(e=5){this.points=[],this.pointsLen=e,this.clear()}clear(){this.points=new Array(this.pointsLen)}addMovement({x:e,y:t}){this.points.pop(),this.points.unshift(new u(e,t))}getYAcceleration(e=1){const t=this.points[0],n=this.points[e];return t&&n?(t.y-n.y)/Math.pow(t.timeStamp-n.timeStamp,2):0}}let h=[];class p extends o.Component{constructor(){super(...arguments),this.veilRef=o.createRef(),this.sheetRef=o.createRef(),this.sheetTopRef=o.createRef(),this.sheetContentBoxRef=o.createRef(),this.sheetScrollContainerRef=o.createRef(),this.velocityTracker=new d,this.observer=null,this.resizeWindowTimer=null,this.state={startScrollTop:0,startY:0,deltaY:0,prevSheetHeight:0,swipeAreaTouched:!1,contentTouched:!1,veilTouched:!1,isAnimating:!1,inWindowResizeScope:!1},this.setStyles=({status:e,deltaHeight:t=0})=>{if(!this.sheetRef.current||!this.veilRef.current)return;const n=this.sheetHeight-t,o="showing"===e?`translate3d(0, -${n}px, 0)`:"translate3d(0, 0, 0)";let i=0;"showing"===e&&(i=0===t?1:n/this.sheetHeight),this.veilRef.current.style.opacity=String(i),this.sheetRef.current.style.transform=o},this.getAvailableContentHeight=e=>{const t=.9*window.innerHeight-this.sheetTopHeight;return e>=t?t:e},this.show=()=>{this.setState({isAnimating:!0},(()=>{this.setStyles({status:"showing"}),this.setHash()}))},this.hide=()=>{this.setState({isAnimating:!0},(()=>{this.setStyles({status:"hiding"}),this.removeHash()}))},this.onSwipeAreaTouchStart=e=>{this.velocityTracker.clear(),this.setState({startY:e.nativeEvent.touches[0].clientY,swipeAreaTouched:!0})},this.onContentTouchStart=e=>{this.props.allowHideOnContentScroll&&!this.state.swipeAreaTouched&&(this.velocityTracker.clear(),this.setState({startY:e.nativeEvent.touches[0].clientY,startScrollTop:this.sheetScrollTop,contentTouched:!0}))},this.onSwipeAriaTouchMove=e=>{const t=e.nativeEvent.touches[0].clientY-this.state.startY;this.velocityTracker.addMovement({x:e.nativeEvent.touches[0].clientX,y:e.nativeEvent.touches[0].clientY}),this.setState({deltaY:t}),t<=0||this.setStyles({status:"showing",deltaHeight:t})},this.onContentTouchMove=e=>{if(!this.props.allowHideOnContentScroll)return;if(!this.state.startY)return void this.onContentTouchStart(e);const{startScrollTop:t,swipeAreaTouched:n}=this.state;if(n||this.sheetScrollTop>0||t>0&&t!==this.sheetScrollTop)return;const o=e.nativeEvent.touches[0].clientY-this.state.startY;this.velocityTracker.addMovement({x:e.nativeEvent.touches[0].clientX,y:e.nativeEvent.touches[0].clientY}),this.setState({deltaY:o}),o<=0||this.setStyles({status:"showing",deltaHeight:o})},this.onTouchEndAction=e=>{const t=this.velocityTracker.getYAcceleration();this.sheetHeight<=e?this.props.hideSheet():e>50&&t<=.08&&t>=-.02||t>.08?this.hide():0!==e&&this.show()},this.onSwipeAriaTouchEnd=()=>{const{deltaY:e}=this.state;this.onTouchEndAction(e),this.setState({startY:0,deltaY:0,swipeAreaTouched:!1})},this.onContentTouchEnd=()=>{const{deltaY:e,swipeAreaTouched:t}=this.state;this.props.allowHideOnContentScroll&&!t&&(this.onTouchEndAction(e),this.setState({startY:0,deltaY:0,contentTouched:!1}))},this.onVeilClick=()=>{this.setState({veilTouched:!0}),this.hide()},this.onVeilTransitionEnd=()=>{this.setState({isAnimating:!1}),"0"===this.veilOpacity&&this.props.hideSheet()},this.onContentTransitionEnd=e=>{"height"===e.propertyName&&this.sheetScrollContainerRef.current&&(this.sheetScrollContainerRef.current.style.transition="none")},this.onResizeWindow=()=>{this.state.isAnimating||(this.setState({inWindowResizeScope:!0}),this.resizeWindowTimer&&window.clearTimeout(this.resizeWindowTimer),this.resizeWindowTimer=window.setTimeout((()=>{this.onResize()}),50))},this.onResize=()=>{if(!this.sheetRef.current||!this.sheetScrollContainerRef.current)return;const e=this.sheetContentHeight;if(e===this.state.prevSheetHeight&&!this.state.inWindowResizeScope)return;const t=this.getAvailableContentHeight(e);this.sheetScrollContainerRef.current.style.transition=this.state.prevSheetHeight>e?"height 0s ease 0.3s":"none",this.sheetScrollContainerRef.current.style.height=`${t}px`,this.sheetRef.current.style.transform=`translate3d(0, -${t+this.sheetTopHeight}px, 0)`,this.setState({prevSheetHeight:e,inWindowResizeScope:!1})}}componentDidMount(){this.addListeners(),this.show();const e=this.getAvailableContentHeight(this.sheetContentHeight);this.setInitialStyles(e),this.setState({prevSheetHeight:e})}componentDidUpdate(e){const{visible:t,location:n}=this.props;!e.visible&&t&&this.show(),(e.visible&&!t||this.shouldClose(e))&&this.hide(),e.location.pathname!==n.pathname&&(h=[])}componentWillUnmount(){this.removeListeners()}render(){const{content:e,contentClassName:t,swipeAreaClassName:n,hideTopBar:i,title:s}=this.props,{deltaY:r,swipeAreaTouched:l,contentTouched:a,veilTouched:u,isAnimating:d}=this.state,h={"with-transition":!r||u},p={"with-transition":h["with-transition"]},v={"without-scroll":r>0&&a||l};return o.createElement(o.Fragment,null,o.createElement("div",{ref:this.veilRef,className:c("veil",h),onClick:d?void 0:this.onVeilClick,onTransitionEnd:this.onVeilTransitionEnd,role:"presentation"}),o.createElement("div",{ref:this.sheetRef,className:c("sheet",p),role:"dialog","aria-modal":"true","aria-label":s},!i&&o.createElement("div",{ref:this.sheetTopRef,className:c("sheet-top")},o.createElement("div",{className:c("sheet-top-resizer")})),o.createElement("div",{className:c("sheet-swipe-area",n),onTouchStart:this.onSwipeAreaTouchStart,onTouchMove:this.onSwipeAriaTouchMove,onTouchEnd:this.onSwipeAriaTouchEnd}),o.createElement("div",{ref:this.sheetScrollContainerRef,className:c("sheet-scroll-container",v),onTouchStart:this.onContentTouchStart,onTouchMove:this.onContentTouchMove,onTouchEnd:this.onContentTouchEnd,onTransitionEnd:this.onContentTransitionEnd},o.createElement("div",{ref:this.sheetContentBoxRef,className:c("sheet-content-box")},o.createElement("div",{className:c("sheet-content-box-border-compensation")},o.createElement("div",{className:c("sheet-content",t)},s&&o.createElement("div",{className:c("sheet-content-title")},s),o.createElement("div",null,e)))))))}get veilOpacity(){var e;return(null===(e=this.veilRef.current)||void 0===e?void 0:e.style.opacity)||0}get sheetTopHeight(){var e;return(null===(e=this.sheetTopRef.current)||void 0===e?void 0:e.getBoundingClientRect().height)||0}get sheetHeight(){var e;return(null===(e=this.sheetRef.current)||void 0===e?void 0:e.getBoundingClientRect().height)||0}get sheetScrollTop(){var e;return(null===(e=this.sheetScrollContainerRef.current)||void 0===e?void 0:e.scrollTop)||0}get sheetContentHeight(){var e;return(null===(e=this.sheetContentBoxRef.current)||void 0===e?void 0:e.getBoundingClientRect().height)||0}setInitialStyles(e){this.sheetScrollContainerRef.current&&this.sheetContentBoxRef.current&&(this.sheetScrollContainerRef.current.style.height=`${e}px`)}addListeners(){window.addEventListener("resize",this.onResizeWindow),this.sheetContentBoxRef.current&&(this.observer=new ResizeObserver((()=>{this.state.inWindowResizeScope||this.onResize()})),this.observer.observe(this.sheetContentBoxRef.current))}removeListeners(){window.removeEventListener("resize",this.onResizeWindow),this.observer&&this.observer.disconnect()}setHash(){const{id:e,platform:t,location:n,history:o}=this.props;if(t===l.O.BROWSER)return;const i=Object.assign(Object.assign({},n),{hash:e});switch(t){case l.O.IOS:n.hash&&h.push(n.hash),o.replace(i);break;case l.O.ANDROID:o.push(i)}}removeHash(){var e;const{id:t,platform:n,location:o,history:i}=this.props;if(n!==l.O.BROWSER&&o.hash===`#${t}`)switch(n){case l.O.IOS:i.replace(Object.assign(Object.assign({},o),{hash:null!==(e=h.pop())&&void 0!==e?e:""}));break;case l.O.ANDROID:i.goBack()}}shouldClose(e){const{id:t,platform:n,location:o,history:i}=this.props;return n!==l.O.BROWSER&&"POP"===i.action&&e.location.hash!==o.hash&&o.hash!==`#${t}`}}p.defaultProps={id:"sheet",allowHideOnContentScroll:!0};const v=function(e){var t;const n=(i=e).displayName||i.name||"Component";var i;return(t=class extends o.Component{render(){return o.createElement(e,Object.assign({},this.props,{mobile:this.context.mobile,platform:this.context.platform,useHistory:this.context.useHistory,useLocation:this.context.useLocation}))}}).displayName=`withMobile(${n})`,t.contextType=a.G,t}(function(e){const t=t=>{const{useHistory:n,useLocation:i}=t,s=(0,r.Tt)(t,["useHistory","useLocation"]);return o.createElement(e,Object.assign({},s,{history:n(),location:i()}))},n=e.displayName||e.name||"Component";return t.displayName=`withRouterWrapper(${n})`,t}(p)),m=({children:e,onClose:t,visible:n,id:r,title:l,className:a,contentClassName:u,swipeAreaClassName:d,allowHideOnContentScroll:h,hideTopBar:p,qa:m})=>{const[f,g]=o.useState(n),[b,E]=o.useState(n);(0,i.y)({enabled:f}),!b&&n&&g(!0),n!==b&&E(n);return f?o.createElement(s.Z,null,o.createElement("div",{"data-qa":m,className:c(null,a)},o.createElement(v,{id:r,content:e,contentClassName:u,swipeAreaClassName:d,title:l,visible:n,allowHideOnContentScroll:h,hideTopBar:p,hideSheet:()=>{t&&t(),g(!1)}}))):null}},13066:(e,t,n)=>{n.d(t,{A:()=>i});var o=n(59284);const i=e=>o.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),o.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M2.97 5.47a.75.75 0 0 1 1.06 0L8 9.44l3.97-3.97a.75.75 0 1 1 1.06 1.06l-4.5 4.5a.75.75 0 0 1-1.06 0l-4.5-4.5a.75.75 0 0 1 0-1.06",clipRule:"evenodd"}))},19884:(e,t,n)=>{n.d(t,{Y:()=>b});var o=n(59284),i=n(94420),s=n(13066),r=n(905),l=n.n(r),a=n(90826),c=n(99991),u=n(84375),d=n(56353),h=n(89226),p=n(81240);const v=e=>{const{size:t,onClick:n,onMouseEnter:i,onMouseLeave:s,renderIcon:r}=e,l=r?r():o.createElement(c.I,{className:(0,d.Di)("clear"),data:p.A});return o.createElement("button",{className:(0,d.Di)({size:t}),"aria-label":(0,h.A)("label_clear"),onClick:n,onMouseEnter:i,onMouseLeave:s,"data-qa":d.pn.CLEAR,type:"button"},l)};v.displayName="SelectClear";var m=n(98089);const f=(0,n(69220).om)("select-counter");function g({count:e,size:t,disabled:n}){return o.createElement("div",{className:f({size:t})},o.createElement(m.E,{variant:"xl"===t?"body-2":"body-1",color:n?"hint":"primary",className:f("text")},e))}const b=o.forwardRef(((e,t)=>{const{toggleOpen:n,clearValue:r,onKeyDown:p,renderControl:m,view:f,size:b,pin:E,selectedOptionsContent:C,className:w,qa:T,label:y,placeholder:S,isErrorVisible:O,errorMessage:R,open:A,disabled:x,value:N,hasClear:H,popupId:I,selectId:k,activeIndex:z,renderCounter:P,hasCounter:L,title:M}=e,B=Boolean(C),D=Boolean(S&&!B),F=Array.isArray(N)&&!l()(N.filter(Boolean)),W=(0,a.u)(),[Y,_]=o.useState(!1),j={open:A,size:b,pin:E,disabled:x,error:O,"has-clear":H,"no-active":Y,"has-value":F},$={open:A,size:b,view:f,pin:E,disabled:x,error:O},q=o.useCallback((e=>{e&&e.currentTarget!==document.activeElement&&"focus"in e.currentTarget&&e.currentTarget.focus(),n()}),[n]),V=o.useCallback((()=>{_(!0)}),[]),G=o.useCallback((()=>{_(!1)}),[]),K=o.useCallback((()=>{_(!1),r()}),[r]),U=()=>{if(!L)return null;const e=N.length,t=o.createElement(g,{count:e,size:b,disabled:x});return P?P(t,{count:e,size:b,disabled:x}):t},J=e=>{const t=0===N.length;return!H||t||x?null:o.createElement(v,{size:b,onClick:K,onMouseEnter:V,onMouseLeave:G,renderIcon:e.renderIcon})},Z={id:k,role:"combobox","aria-controls":A?I:void 0,"aria-haspopup":"listbox","aria-expanded":A,"aria-activedescendant":void 0===z?void 0:`${I}-item-${z}`,onClick:q,onKeyDown:p,disabled:x};return m?m({onKeyDown:p,onClear:r,onClick:q,renderClear:J,renderCounter:U,ref:t,open:A,popupId:I,selectId:k,activeIndex:z,disabled:x,triggerProps:Z},{value:N}):o.createElement(o.Fragment,null,o.createElement("div",{className:(0,d.ji)(j),role:"group"},o.createElement("button",Object.assign({ref:t,className:(0,d.Zz)($,w),type:"button","data-qa":T,title:M,tabIndex:0},Z),y&&o.createElement("span",{className:(0,d.ji)("label")},y),D&&o.createElement("span",{className:(0,d.ji)("placeholder")},S),B&&o.createElement("span",{className:(0,d.ji)("option-text")},C)),U(),J({}),R&&o.createElement(u.A,{content:R,tooltipId:W},o.createElement("button",{"aria-label":(0,h.A)("label_show-error-info"),"aria-describedby":W,className:(0,d.ji)("error-icon")},o.createElement(c.I,{data:i.A,size:"s"===b?12:16}))),o.createElement(c.I,{className:(0,d.ji)("chevron-icon",{disabled:x}),data:s.A,"aria-hidden":"true"})))}));b.displayName="SelectControl"},24555:(e,t,n)=>{n.d(t,{l:()=>te});var o=n(59284),i=n(359),s=n(85736),r=n(32084),l=n(27145),a=n(92609);var c=n(90826),u=n(51301),d=n(63246),h=n(34379),p=n(46819),v=n(28664),m=n(69220),f=n(56353),g=n(89226);const b=(0,m.om)("select-filter"),E={padding:"4px 4px 0"},C=o.forwardRef(((e,t)=>{const{onChange:n,onKeyDown:i,renderFilter:s,size:r,value:l,placeholder:a,popupId:c,activeIndex:u}=e,d=o.useRef(null);o.useImperativeHandle(t,(()=>({focus:()=>{var e;return null===(e=d.current)||void 0===e?void 0:e.focus({preventScroll:!0})}})),[]);const h={value:l,placeholder:a,size:1,onKeyDown:i,onChange:e=>{n(e.target.value)},"aria-label":(0,g.A)("label_filter"),"aria-controls":c,"aria-activedescendant":void 0===u?void 0:`${c}-item-${u}`};return s?s({onChange:n,onKeyDown:i,value:l,ref:d,style:E,inputProps:h}):o.createElement("div",{className:b(),style:E},o.createElement(v.k,{controlRef:d,controlProps:{className:b("input"),size:1,"aria-label":h["aria-label"],"aria-controls":h["aria-controls"],"aria-activedescendant":h["aria-activedescendant"]},size:r,value:l,placeholder:a,onUpdate:n,onKeyDown:i,qa:f.pn.FILTER_INPUT}))}));C.displayName="SelectFilter";var w=n(40091);const T=e=>Boolean(e&&"label"in e),y=e=>{const{getOptionHeight:t,getOptionGroupHeight:n,size:o,option:i,index:s,mobile:r}=e;let l=r?f.t5:f.KK[o];if(T(i)){const e=0===s?0:f.Vm;return l=""===i.label?0:l,n?n(i,s):l+e}return t?t(i,s):l},S=e=>"string"===typeof e.content?e.content:"string"===typeof e.children?e.children:e.text?e.text:e.value,O=e=>(e=>o.Children.toArray(e))(e).reduce(((e,{props:t})=>{if("label"in t){const n=t.options||(e=>o.Children.toArray(e).reduce(((e,{props:t})=>("value"in t&&e.push(t),e)),[]))(t.children);e.push({options:n,label:t.label})}return"value"in t&&e.push(Object.assign({},t)),e}),[]),R=(e,t)=>t?t.findIndex((t=>{if(T(t))return!1;if(t.disabled)return!1;const n=S(t);return(o=e,new RegExp(o.replace(/[-/\\^$*+?.()|[\]{}]/g,"\\$&"),"i")).test(n);var o})):-1,A=e=>{var t;return(null===(t=null===e||void 0===e?void 0:e.current)||void 0===t?void 0:t.getItems())||[]},x=e=>{const{options:t,filter:n,filterOption:o}=e,i=t.filter((e=>!!T(e)||(o?o(e,n):((e,t)=>{const n=S(e).toLocaleLowerCase(),o=t.toLocaleLowerCase();return-1!==n.indexOf(o)})(e,n))));return i.reduce(((e,t,n)=>{const o=T(t),s=T(e[e.length-1]),r=n===i.length-1;return o&&s&&e.pop(),(!o||o&&!r)&&e.push(t),e}),[])};function N(e){const t=e.offsetParent;if(t instanceof HTMLElement){const n=t.offsetHeight,o=t.scrollTop,i=e.offsetTop;i+e.offsetHeight>=o+n?t.scrollTo({top:i-n+e.offsetHeight}):i<=o&&t.scrollTo({top:i})}return!0}const H=(0,m.om)("select-list"),I=({option:e,renderOptionGroup:t})=>t?o.createElement("div",{className:H("group-label-custom")},t(e)):o.createElement("div",{className:H("group-label",{empty:""===e.label})},o.createElement("div",{className:H("group-label-content")},e.label));var k=n(25569),z=n(99991);const P=(0,m.om)("select-list"),L=({option:e})=>{const{content:t,children:n,disabled:i,title:s}=e;return o.createElement("span",{title:s,className:P("option-default-label",{disabled:i})},t||n)},M=e=>{const{renderOption:t,value:n,option:i,multiple:s}=e,r=-1!==n.indexOf(i.value),l=t?t(i):o.createElement(L,{option:i});return o.createElement("div",{"data-qa":i.qa,className:P("option",{colored:r&&!s,disabled:i.disabled})},s&&o.createElement(z.I,{className:P("tick-icon",{shown:r&&s}),data:k.A}),l)};var B=n(29322),D=n(74417);const F=e=>{const t=o.useRef(null);return(0,B.v)({element:t.current,onIntersect:null===e||void 0===e?void 0:e.onIntersect}),o.createElement("div",{ref:t,className:(0,f.C1)("loading-indicator")},o.createElement(D.a,null))},W={value:"__SELECT_LIST_ITEM_LOADING__",disabled:!0},Y=o.forwardRef(((e,t)=>{const{onOptionClick:n,renderOption:i,renderOptionGroup:s,getOptionHeight:r,getOptionGroupHeight:l,size:a,flattenOptions:c,value:u,multiple:d,virtualized:h,mobile:p,loading:v,onLoadMore:m,id:g,activeIndex:b,onChangeActive:E}=e,C=o.useMemo((()=>v?[...c,W]:c),[c,v]),T=o.useMemo((()=>c.reduce(((e,t,n)=>("value"in t&&u.includes(t.value)&&e.push(n),e)),[])),[c,u]),S=(e=>{const{getOptionHeight:t,getOptionGroupHeight:n,size:o,options:i,mobile:s}=e;return i.reduce(((e,i,r)=>e+y({getOptionHeight:t,getOptionGroupHeight:n,size:o,option:i,index:r,mobile:s})),0)})({options:C,getOptionHeight:r,getOptionGroupHeight:l,size:a,mobile:p}),O=o.useCallback(((e,t)=>y({getOptionHeight:r,getOptionGroupHeight:l,size:a,option:e,index:t,mobile:p})),[r,l,p,a]),R=o.useCallback(((e,t,n)=>{if("label"in e){const t=s?e=>s(e,{itemHeight:O(e,n)}):void 0;return o.createElement(I,{option:e,renderOptionGroup:t})}if(e.value===W.value)return o.createElement(F,{onIntersect:0===n?void 0:m});const r=i?e=>i(e,{itemHeight:O(e,n)}):void 0;return o.createElement(M,{option:e,value:u,multiple:d,renderOption:r})}),[i,s,u,d,O,m]);return o.createElement(w.B,{ref:t,className:(0,f.C1)({size:a,virtualized:h,mobile:p}),qa:f.pn.LIST,itemClassName:(0,f.C1)("item"),itemHeight:O,itemsHeight:h?S:void 0,items:C,filterable:!1,virtualized:h,renderItem:R,onItemClick:n,selectedItemIndex:T,id:g,role:"listbox",activeItemIndex:b,onChangeActive:E,deactivateOnLeave:!1,onScrollToItem:N})}));Y.displayName="SelectList";const _=(0,m.om)("select-empty-placeholder"),j=({renderEmptyOptions:e,filter:t})=>o.createElement("div",{className:_({empty:!e})},null===e||void 0===e?void 0:e({filter:t}));var $=n(19884),q=n(93628),V=n(794);function G(e){const{name:t,value:n,disabled:i,form:s,onReset:r}=e,l=(0,V.d)({onReset:r,initialValue:n});return!t||i?null:0===n.length?o.createElement("input",{ref:l,type:"hidden",name:t,value:n,form:s,disabled:i}):o.createElement(o.Fragment,null,n.map(((e,n)=>o.createElement("input",{key:e,ref:0===n?l:void 0,value:e,type:"hidden",name:t,form:s,disabled:i}))))}const K=e=>{const{onChange:t,open:n,disabled:s}=e,[r,l]=o.useState(""),[a,c]=o.useState(),u=o.useCallback((e=>{if(clearTimeout(a),e){const e=window.setTimeout((()=>l("")),f.FY);c(e)}}),[a]),d=o.useCallback((e=>{e.stopPropagation();const t=((e,t)=>{const n=1===e.length;let o="";return e===i.D.BACKSPACE&&t.length?o=t.slice(0,t.length-1):n&&(o=(t+e).trim()),o})(e.key,r);r!==t&&(u(t),l(t))}),[u,r]);o.useEffect((()=>(n&&!s?document.addEventListener("keydown",d):n||s||l(""),()=>{n&&!s&&document.removeEventListener("keydown",d)})),[d,n,s]),o.useEffect((()=>(n||clearTimeout(a),()=>clearTimeout(a))),[n,a]),o.useEffect((()=>{t(r)}),[t,r])};function U(e,t){let n=-1;return t.length>0&&(n=e.findIndex((e=>"value"in e&&t.includes(e.value)&&!e.disabled))),-1===n&&(n=e.findIndex((e=>"value"in e&&!e.disabled))),-1===n?void 0:n}var J=n(87924),Z=n.n(J);function X(e){return Z()(e,[f.zJ])}function Q(e){const{filter:t="",filterable:n,filterOption:i}=e,s=o.useMemo((()=>X(e.options)?e.options:(e=>{const t=e.reduce(((e,t)=>("label"in t?(e.push({label:t.label,disabled:!0,data:t.data}),e.push(...t.options||[])):e.push(t),e)),[]);return Object.defineProperty(t,f.zJ,{enumerable:!1,value:{}}),t})(e.options)),[e.options]),r=o.useMemo((()=>n?x({options:s,filter:t,filterOption:i}):s),[t,n,i,s]);return s[f.zJ].filteredOptions=r,s}const ee=({renderFilter:e,renderList:t})=>o.createElement(o.Fragment,null,e(),t()),te=o.forwardRef((function(e,t){const{onUpdate:n,onOpenChange:v,onFilterChange:m,renderControl:g,renderFilter:b,renderOption:E,renderOptionGroup:w,renderSelectedOption:y,renderEmptyOptions:x,renderPopup:N=ee,getOptionHeight:H,getOptionGroupHeight:I,filterOption:k,name:z,form:P,className:L,controlClassName:M,popupClassName:B,qa:D,value:F,defaultValue:W,defaultOpen:_,open:V,label:J,placeholder:te,filterPlaceholder:ne,width:oe,popupWidth:ie,popupPlacement:se,error:re,virtualizationThreshold:le=f.Us,view:ae="normal",size:ce="m",pin:ue="round-round",multiple:de=!1,disabled:he=!1,filterable:pe=!1,filter:ve,disablePortal:me,hasClear:fe=!1,onClose:ge,id:be,hasCounter:Ee,renderCounter:Ce,title:we}=e,Te=(0,p.I)(),[ye,Se]=(0,s.P)(ve,"",m),Oe=o.useRef(null),Re=o.useRef(null),Ae=o.useRef(null),xe=o.useRef(null),Ne=(0,r.N)(t,Re),{value:He,open:Ie,toggleOpen:ke,setValue:ze,handleSelection:Pe,handleClearValue:Le}=(({defaultOpen:e,onClose:t,onOpenChange:n,open:i,value:r,defaultValue:c=[],multiple:u,onUpdate:d,disabled:h})=>{const[p,v]=(0,s.P)(r,c,d),[m,f]=o.useState(),g=(0,a.F)({defaultOpen:e,onClose:t,onOpenChange:n,open:i}),{toggleOpen:b}=g,E=(0,l.Tt)(g,["toggleOpen"]),C=o.useCallback((e=>{h||v(e)}),[v,h]),w=o.useCallback((e=>{if(!p.includes(e.value)){const t=[e.value];C(t)}b(!1)}),[p,C,b]),T=o.useCallback((e=>{const t=p.includes(e.value)?p.filter((t=>t!==e.value)):[...p,e.value];C(t)}),[p,C]),y=o.useCallback((e=>{u?T(e):w(e)}),[u,w,T]),S=o.useCallback((()=>{C([])}),[C]);return Object.assign({value:p,activeIndex:m,setValue:C,handleSelection:y,handleClearValue:S,toggleOpen:b,setActiveIndex:f},E)})({onUpdate:n,value:F,defaultValue:W,defaultOpen:_,multiple:de,open:V,onClose:ge,onOpenChange:v,disabled:he});o.useEffect((()=>{!Ie&&pe&&Te&&setTimeout((()=>{Se("")}),300)}),[Ie,pe,Se,Te]);const Me=Q({options:e.options||O(e.children),filter:ye,filterable:pe,filterOption:k}),Be=function(e){if(!X(e))throw Error("You should use options generated by useSelectOptions hook");return Z()(e,[f.zJ,"filteredOptions"])}(Me),De=((e,t,n)=>{if(0===t.length)return null;const i=e.filter((e=>!T(e))),s=t.reduce(((e,t)=>{const n=i.find((e=>e.value===t));return e.push(n||{value:t}),e}),[]);return n?s.map(((e,t)=>o.createElement(o.Fragment,{key:e.value},n(e,t)))):s.map((e=>S(e))).join(", ")})(Me,He,y),Fe=Be.length>=le,{errorMessage:We,errorPlacement:Ye,validationState:_e}=(0,h.Av)({error:re,errorMessage:e.errorMessage,errorPlacement:e.errorPlacement||"outside",validationState:e.validationState}),je=(0,c.u)(),$e="invalid"===_e,qe=$e&&Boolean(We)&&"outside"===Ye,Ve=$e&&Boolean(We)&&"inside"===Ye,Ge=o.useCallback((e=>{var t,n;if(e&&!(null===e||void 0===e?void 0:e.disabled)&&!("label"in e)){if(de){const e=null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t?void 0:t.getActiveItem();null===(n=Ae.current)||void 0===n||n.focus(),"number"===typeof e&&setTimeout((()=>{var t;null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.activateItem(e,!0)}),50)}Pe(e)}}),[Pe,de]),Ke=o.useCallback((e=>{var t;[i.D.ENTER,i.D.SPACEBAR].includes(e.key)&&Ie&&(e.preventDefault(),e.key===i.D.SPACEBAR&&Ge((e=>{var t;const n=A(e),o=null===(t=null===e||void 0===e?void 0:e.current)||void 0===t?void 0:t.getActiveItem();return"number"===typeof o?n[o]:void 0})(xe))),[i.D.ARROW_DOWN,i.D.ARROW_UP].includes(e.key)&&!Ie&&(e.preventDefault(),ke()),null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.onKeyDown(e)}),[Ge,Ie,ke]),Ue=o.useCallback((e=>{var t;null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.onKeyDown(e)}),[]),Je=o.useCallback((e=>{var t;if(e){const n=R(e,A(xe));"number"===typeof n&&-1!==n&&(null===(t=null===xe||void 0===xe?void 0:xe.current)||void 0===t||t.activateItem(n,!0))}}),[]);K({onChange:Je,open:Ie,disabled:pe}),o.useEffect((()=>{var e;Ie&&pe&&(null===(e=Ae.current)||void 0===e||e.focus())}),[Ie,pe]);const Ze=Object.assign({},"max"===oe&&{width:oe}),Xe={};"number"===typeof oe&&(Xe.width=oe);const Qe=o.useCallback((()=>ke(!1)),[ke]),{onFocus:et,onBlur:tt}=e,{focusWithinProps:nt}=(0,u.R)({onFocusWithin:et,onBlurWithin:o.useCallback((e=>{null===tt||void 0===tt||tt(e),Qe()}),[Qe,tt])}),ot=(0,c.u)(),it=null!==be&&void 0!==be?be:ot,st=`select-popup-${it}`,[rt,lt]=function({options:e,value:t,open:n}){const[i,s]=o.useState((()=>{if(n)return U(e,t)})),[r,l]=o.useState(n);return r!==n&&(l(n),n&&s(U(e,t))),[n&&void 0!==i&&i{Se("")}:void 0},N({renderFilter:()=>pe?o.createElement(C,{ref:Ae,size:ce,value:ye,placeholder:ne,onChange:Se,onKeyDown:Ue,renderFilter:b,popupId:st,activeIndex:rt}):null,renderList:()=>Be.length||e.loading?o.createElement(Y,{ref:xe,size:ce,value:He,mobile:Te,flattenOptions:Be,multiple:de,virtualized:Fe,onOptionClick:Ge,renderOption:E,renderOptionGroup:w,getOptionHeight:H,getOptionGroupHeight:I,loading:e.loading,onLoadMore:e.onLoadMore,id:st,activeIndex:rt,onChangeActive:lt}):o.createElement(j,{filter:ye,renderEmptyOptions:x})})),o.createElement(d.o,{errorMessage:qe?We:null,errorMessageId:je}),o.createElement(G,{name:z,value:He,disabled:he,form:P,onReset:ze}))}));te.Option=e=>null,te.OptionGroup=e=>null},25569:(e,t,n)=>{n.d(t,{A:()=>i});var o=n(59284);const i=e=>o.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),o.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.488 3.43a.75.75 0 0 1 .081 1.058l-6 7a.75.75 0 0 1-1.1.042l-3.5-3.5A.75.75 0 0 1 4.03 6.97l2.928 2.927 5.473-6.385a.75.75 0 0 1 1.057-.081",clipRule:"evenodd"}))},33705:(e,t,n)=>{n.d(t,{I:()=>l});var o=n(59284),i=n(13066),s=n(99991);const r=(0,n(69220).om)("arrow-toggle");function l({size:e=16,direction:t="bottom",className:n,qa:l}){return o.createElement("span",{style:{width:e,height:e},className:r({direction:t},n),"data-qa":l},o.createElement(s.I,{data:i.A,size:e}))}},51301:(e,t,n)=>{n.d(t,{R:()=>s});var o=n(59284);class i{constructor(e,t,n={}){var o,i;this.nativeEvent=t,this.target=null!==(o=n.target)&&void 0!==o?o:t.target,this.currentTarget=null!==(i=n.currentTarget)&&void 0!==i?i:t.currentTarget,this.relatedTarget=t.relatedTarget,this.bubbles=t.bubbles,this.cancelable=t.cancelable,this.defaultPrevented=t.defaultPrevented,this.eventPhase=t.eventPhase,this.isTrusted=t.isTrusted,this.timeStamp=t.timeStamp,this.type=e}isDefaultPrevented(){return this.nativeEvent.defaultPrevented}preventDefault(){this.defaultPrevented=!0,this.nativeEvent.preventDefault()}stopPropagation(){this.nativeEvent.stopPropagation(),this.isPropagationStopped=()=>!0}isPropagationStopped(){return!1}persist(){}}function s(e){const{onFocusWithin:t,onBlurWithin:n,onFocusWithinChange:s,isDisabled:r}=e,l=o.useRef(!1),a=o.useCallback((e=>{l.current||document.activeElement!==e.target||(l.current=!0,t&&t(e),s&&s(!0))}),[t,s]),c=o.useCallback((e=>{l.current&&(l.current=!1,n&&n(e),s&&s(!1))}),[n,s]),{onBlur:u,onFocus:d}=function({onFocus:e,onBlur:t,isDisabled:n}){const s=o.useRef(!1),r=o.useRef(null);o.useEffect((()=>{if(n)return;const e=function(){s.current=!1},o=function(e){if(!s.current&&r.current){const n=new FocusEvent("blur",Object.assign(Object.assign({},e),{relatedTarget:e.target,bubbles:!1,cancelable:!1}));t(new i("blur",n,{target:r.current,currentTarget:r.current})),r.current=null}};return window.addEventListener("focus",e,{capture:!0}),window.addEventListener("focusin",o),()=>{window.removeEventListener("focus",e,{capture:!0}),window.removeEventListener("focusin",o)}}),[n,t]);const l=o.useCallback((e=>{document.activeElement===e.target||null!==e.relatedTarget&&e.relatedTarget!==document.body&&e.relatedTarget!==document||(t(e),r.current=null)}),[t]),a=function(e){const t=o.useRef({isFocused:!1,observer:null});return o.useEffect((()=>{const e=t.current;return()=>{e.observer&&(e.observer.disconnect(),e.observer=null)}}),[]),o.useCallback((n=>{const o=n.target;if(o instanceof HTMLButtonElement||o instanceof HTMLInputElement||o instanceof HTMLTextAreaElement||o instanceof HTMLSelectElement){t.current.isFocused=!0;const n=n=>{t.current.isFocused=!1,o.disabled&&(null===e||void 0===e||e(new i("blur",n))),t.current.observer&&(t.current.observer.disconnect(),t.current.observer=null)};o.addEventListener("focusout",n,{once:!0});const s=new MutationObserver((()=>{if(t.current.isFocused&&o.disabled){s.disconnect(),t.current.observer=null;const e=o===document.activeElement?null:document.activeElement;o.dispatchEvent(new FocusEvent("blur",{relatedTarget:e})),o.dispatchEvent(new FocusEvent("focusout",{relatedTarget:e,bubbles:!0}))}}));s.observe(o,{attributes:!0,attributeFilter:["disabled"]}),t.current.observer=s}}),[e])}(t),c=o.useCallback((t=>{s.current=!0,r.current=t.target,a(t),e(t)}),[a,e]);return{onBlur:l,onFocus:c}}({onFocus:a,onBlur:c,isDisabled:r});return r?{focusWithinProps:{onFocus:void 0,onBlur:void 0}}:{focusWithinProps:{onFocus:d,onBlur:u}}}},56353:(e,t,n)=>{n.d(t,{C1:()=>l,Di:()=>a,Eq:()=>p,FY:()=>v,KK:()=>c,Us:()=>m,Vm:()=>d,Zz:()=>r,gP:()=>h,gm:()=>i,ji:()=>s,pn:()=>f,t5:()=>u,zJ:()=>g});var o=n(69220);const i=(0,o.om)("select"),s=(0,o.om)("select-control"),r=(0,o.om)("select-control__button"),l=(0,o.om)("select-list"),a=(0,o.om)("select-clear"),c={s:28,m:28,l:32,xl:36},u=32,d=5,h=1,p=100,v=2e3,m=50,f={LIST:"select-list",POPUP:"select-popup",SHEET:"select-sheet",CLEAR:"select-clear",FILTER_INPUT:"select-filter-input"},g=Symbol("flatten")},89226:(e,t,n)=>{n.d(t,{A:()=>r});var o=n(72837);const i=JSON.parse('{"label_clear":"Clear","label_show-error-info":"Show popup with error info","label_filter":"Filter"}'),s=JSON.parse('{"label_clear":"\u041e\u0447\u0438\u0441\u0442\u0438\u0442\u044c","label_show-error-info":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043f\u043e\u043f\u0430\u043f \u0441 \u0438\u043d\u0444\u043e\u0440\u043c\u0430\u0446\u0435\u0439 \u043e\u0431 \u043e\u0448\u0438\u0431\u043a\u0435","label_filter":"\u0424\u0438\u043b\u044c\u0442\u0440"}'),r=(0,o.N)({en:i,ru:s},"Select")},92609:(e,t,n)=>{n.d(t,{F:()=>s});var o=n(59284),i=n(85736);const s=e=>{var t;const{onOpenChange:n,onClose:s}=e,r=o.useCallback((e=>{null===n||void 0===n||n(e),!1===e&&s&&s()}),[n,s]),[l,a]=(0,i.P)(e.open,null!==(t=e.defaultOpen)&&void 0!==t&&t,r),c=o.useCallback((e=>{a("boolean"===typeof e?e:!l)}),[l,a]);return{open:l,toggleOpen:c}}},93628:(e,t,n)=>{n.d(t,{t:()=>p});var o=n(59284),i=n(39238),s=n(12640),r=n(69220),l=n(56353);const a=e=>e-2*l.gP,c=(e,t,n)=>{let o=t;return o="number"===typeof e?e:"fit"===e?a(t):((e,t)=>t?e>l.Eq?e:l.Eq:a(e))(t,n),`${o}px`},u=e=>{const{width:t,disablePortal:n,virtualized:o}=e;return[{name:"sameWidth",enabled:!0,phase:"beforeWrite",requires:["computeStyles"],fn:({state:e,name:n})=>{var i;if(null===(i=e.modifiersData[`${n}#persistent`])||void 0===i?void 0:i.skip)return;const s=c(t,e.rects.reference.width,o);"number"!==typeof t&&"fit"!==t?(e.styles.popper.minWidth=s,e.styles.popper.width=void 0):(e.styles.popper.minWidth=s,e.styles.popper.width=s),e.styles.popper.maxWidth=`max(90vw, ${a(e.rects.reference.width)}px)`,e.modifiersData[`${n}#persistent`]={skip:"number"!==typeof t}},effect:({state:e,name:n})=>{var i;if(null===(i=e.modifiersData[`${n}#persistent`])||void 0===i?void 0:i.skip)return;const s=c(t,e.elements.reference.offsetWidth,o);"number"!==typeof t&&"fit"!==t?e.elements.popper.style.minWidth=s:(e.elements.popper.style.minWidth=s,e.elements.popper.style.width=s),e.elements.popper.style.maxWidth=`max(90vw, ${e.elements.reference.offsetWidth}px)`}},{name:"preventOverflow",options:{padding:10,altBoundary:n,altAxis:!0}}]},d=(0,r.om)("select-popup"),h=["bottom-start","bottom-end","top-start","top-end"],p=o.forwardRef((({handleClose:e,onAfterClose:t,width:n,open:r,placement:a=h,controlRef:c,children:p,className:v,disablePortal:m,virtualized:f,mobile:g,id:b},E)=>g?o.createElement(s.c,{qa:l.pn.SHEET,className:v,visible:Boolean(r),onClose:e},p):o.createElement(i.z,{contentClassName:d(null,v),qa:l.pn.POPUP,anchorRef:E,placement:a,offset:[l.gP,l.gP],open:r,onClose:e,disablePortal:m,restoreFocus:!0,restoreFocusRef:c,modifiers:u({width:n,disablePortal:m,virtualized:f}),id:b,onTransitionExited:t},p)));p.displayName="SelectPopup"}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72020.e0c38d22.chunk.js b/ydb/core/viewer/monitoring/static/js/72020.e0c38d22.chunk.js new file mode 100644 index 000000000000..9ff50fffe788 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72020.e0c38d22.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72020],{66089:e=>{function a(e){e.languages.matlab={comment:[/%\{[\s\S]*?\}%/,/%.+/],string:{pattern:/\B'(?:''|[^'\r\n])*'/,greedy:!0},number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[eE][+-]?\d+)?(?:[ij])?|\b[ij]\b/,keyword:/\b(?:NaN|break|case|catch|continue|else|elseif|end|for|function|if|inf|otherwise|parfor|pause|pi|return|switch|try|while)\b/,function:/\b(?!\d)\w+(?=\s*\()/,operator:/\.?[*^\/\\']|[+\-:@]|[<>=~]=?|&&?|\|\|?/,punctuation:/\.{3}|[.,;\[\](){}!]/}}e.exports=a,a.displayName="matlab",a.aliases=[]},72020:(e,a,n)=>{n.d(a,{default:()=>i});var t=n(66089);const i=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7206.6b7278f5.chunk.js b/ydb/core/viewer/monitoring/static/js/7206.6b7278f5.chunk.js deleted file mode 100644 index 99287f19431b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/7206.6b7278f5.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 7206.6b7278f5.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[7206],{57206:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>r,language:()=>s});var r={comments:{lineComment:";;"},brackets:[["[","]"],["(",")"],["{","}"]],autoClosingPairs:[{open:"[",close:"]"},{open:'"',close:'"'},{open:"(",close:")"},{open:"{",close:"}"}],surroundingPairs:[{open:"[",close:"]"},{open:'"',close:'"'},{open:"(",close:")"},{open:"{",close:"}"}]},s={defaultToken:"",ignoreCase:!0,tokenPostfix:".clj",brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"}],constants:["true","false","nil"],numbers:/^(?:[+\-]?\d+(?:(?:N|(?:[eE][+\-]?\d+))|(?:\.?\d*(?:M|(?:[eE][+\-]?\d+))?)|\/\d+|[xX][0-9a-fA-F]+|r[0-9a-zA-Z]+)?(?=[\\\[\]\s"#'(),;@^`{}~]|$))/,characters:/^(?:\\(?:backspace|formfeed|newline|return|space|tab|o[0-7]{3}|u[0-9A-Fa-f]{4}|x[0-9A-Fa-f]{4}|.)?(?=[\\\[\]\s"(),;@^`{}~]|$))/,escapes:/^\\(?:["'\\bfnrt]|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,qualifiedSymbols:/^(?:(?:[^\\\/\[\]\d\s"#'(),;@^`{}~][^\\\[\]\s"(),;@^`{}~]*(?:\.[^\\\/\[\]\d\s"#'(),;@^`{}~][^\\\[\]\s"(),;@^`{}~]*)*\/)?(?:\/|[^\\\/\[\]\d\s"#'(),;@^`{}~][^\\\[\]\s"(),;@^`{}~]*)*(?=[\\\[\]\s"(),;@^`{}~]|$))/,specialForms:[".","catch","def","do","if","monitor-enter","monitor-exit","new","quote","recur","set!","throw","try","var"],coreSymbols:["*","*'","*1","*2","*3","*agent*","*allow-unresolved-vars*","*assert*","*clojure-version*","*command-line-args*","*compile-files*","*compile-path*","*compiler-options*","*data-readers*","*default-data-reader-fn*","*e","*err*","*file*","*flush-on-newline*","*fn-loader*","*in*","*math-context*","*ns*","*out*","*print-dup*","*print-length*","*print-level*","*print-meta*","*print-namespace-maps*","*print-readably*","*read-eval*","*reader-resolver*","*source-path*","*suppress-read*","*unchecked-math*","*use-context-classloader*","*verbose-defrecords*","*warn-on-reflection*","+","+'","-","-'","->","->>","->ArrayChunk","->Eduction","->Vec","->VecNode","->VecSeq","-cache-protocol-fn","-reset-methods","..","/","<","<=","=","==",">",">=","EMPTY-NODE","Inst","StackTraceElement->vec","Throwable->map","accessor","aclone","add-classpath","add-watch","agent","agent-error","agent-errors","aget","alength","alias","all-ns","alter","alter-meta!","alter-var-root","amap","ancestors","and","any?","apply","areduce","array-map","as->","aset","aset-boolean","aset-byte","aset-char","aset-double","aset-float","aset-int","aset-long","aset-short","assert","assoc","assoc!","assoc-in","associative?","atom","await","await-for","await1","bases","bean","bigdec","bigint","biginteger","binding","bit-and","bit-and-not","bit-clear","bit-flip","bit-not","bit-or","bit-set","bit-shift-left","bit-shift-right","bit-test","bit-xor","boolean","boolean-array","boolean?","booleans","bound-fn","bound-fn*","bound?","bounded-count","butlast","byte","byte-array","bytes","bytes?","case","cast","cat","char","char-array","char-escape-string","char-name-string","char?","chars","chunk","chunk-append","chunk-buffer","chunk-cons","chunk-first","chunk-next","chunk-rest","chunked-seq?","class","class?","clear-agent-errors","clojure-version","coll?","comment","commute","comp","comparator","compare","compare-and-set!","compile","complement","completing","concat","cond","cond->","cond->>","condp","conj","conj!","cons","constantly","construct-proxy","contains?","count","counted?","create-ns","create-struct","cycle","dec","dec'","decimal?","declare","dedupe","default-data-readers","definline","definterface","defmacro","defmethod","defmulti","defn","defn-","defonce","defprotocol","defrecord","defstruct","deftype","delay","delay?","deliver","denominator","deref","derive","descendants","destructure","disj","disj!","dissoc","dissoc!","distinct","distinct?","doall","dorun","doseq","dosync","dotimes","doto","double","double-array","double?","doubles","drop","drop-last","drop-while","eduction","empty","empty?","ensure","ensure-reduced","enumeration-seq","error-handler","error-mode","eval","even?","every-pred","every?","ex-data","ex-info","extend","extend-protocol","extend-type","extenders","extends?","false?","ffirst","file-seq","filter","filterv","find","find-keyword","find-ns","find-protocol-impl","find-protocol-method","find-var","first","flatten","float","float-array","float?","floats","flush","fn","fn?","fnext","fnil","for","force","format","frequencies","future","future-call","future-cancel","future-cancelled?","future-done?","future?","gen-class","gen-interface","gensym","get","get-in","get-method","get-proxy-class","get-thread-bindings","get-validator","group-by","halt-when","hash","hash-combine","hash-map","hash-ordered-coll","hash-set","hash-unordered-coll","ident?","identical?","identity","if-let","if-not","if-some","ifn?","import","in-ns","inc","inc'","indexed?","init-proxy","inst-ms","inst-ms*","inst?","instance?","int","int-array","int?","integer?","interleave","intern","interpose","into","into-array","ints","io!","isa?","iterate","iterator-seq","juxt","keep","keep-indexed","key","keys","keyword","keyword?","last","lazy-cat","lazy-seq","let","letfn","line-seq","list","list*","list?","load","load-file","load-reader","load-string","loaded-libs","locking","long","long-array","longs","loop","macroexpand","macroexpand-1","make-array","make-hierarchy","map","map-entry?","map-indexed","map?","mapcat","mapv","max","max-key","memfn","memoize","merge","merge-with","meta","method-sig","methods","min","min-key","mix-collection-hash","mod","munge","name","namespace","namespace-munge","nat-int?","neg-int?","neg?","newline","next","nfirst","nil?","nnext","not","not-any?","not-empty","not-every?","not=","ns","ns-aliases","ns-imports","ns-interns","ns-map","ns-name","ns-publics","ns-refers","ns-resolve","ns-unalias","ns-unmap","nth","nthnext","nthrest","num","number?","numerator","object-array","odd?","or","parents","partial","partition","partition-all","partition-by","pcalls","peek","persistent!","pmap","pop","pop!","pop-thread-bindings","pos-int?","pos?","pr","pr-str","prefer-method","prefers","primitives-classnames","print","print-ctor","print-dup","print-method","print-simple","print-str","printf","println","println-str","prn","prn-str","promise","proxy","proxy-call-with-super","proxy-mappings","proxy-name","proxy-super","push-thread-bindings","pvalues","qualified-ident?","qualified-keyword?","qualified-symbol?","quot","rand","rand-int","rand-nth","random-sample","range","ratio?","rational?","rationalize","re-find","re-groups","re-matcher","re-matches","re-pattern","re-seq","read","read-line","read-string","reader-conditional","reader-conditional?","realized?","record?","reduce","reduce-kv","reduced","reduced?","reductions","ref","ref-history-count","ref-max-history","ref-min-history","ref-set","refer","refer-clojure","reify","release-pending-sends","rem","remove","remove-all-methods","remove-method","remove-ns","remove-watch","repeat","repeatedly","replace","replicate","require","reset!","reset-meta!","reset-vals!","resolve","rest","restart-agent","resultset-seq","reverse","reversible?","rseq","rsubseq","run!","satisfies?","second","select-keys","send","send-off","send-via","seq","seq?","seqable?","seque","sequence","sequential?","set","set-agent-send-executor!","set-agent-send-off-executor!","set-error-handler!","set-error-mode!","set-validator!","set?","short","short-array","shorts","shuffle","shutdown-agents","simple-ident?","simple-keyword?","simple-symbol?","slurp","some","some->","some->>","some-fn","some?","sort","sort-by","sorted-map","sorted-map-by","sorted-set","sorted-set-by","sorted?","special-symbol?","spit","split-at","split-with","str","string?","struct","struct-map","subs","subseq","subvec","supers","swap!","swap-vals!","symbol","symbol?","sync","tagged-literal","tagged-literal?","take","take-last","take-nth","take-while","test","the-ns","thread-bound?","time","to-array","to-array-2d","trampoline","transduce","transient","tree-seq","true?","type","unchecked-add","unchecked-add-int","unchecked-byte","unchecked-char","unchecked-dec","unchecked-dec-int","unchecked-divide-int","unchecked-double","unchecked-float","unchecked-inc","unchecked-inc-int","unchecked-int","unchecked-long","unchecked-multiply","unchecked-multiply-int","unchecked-negate","unchecked-negate-int","unchecked-remainder-int","unchecked-short","unchecked-subtract","unchecked-subtract-int","underive","unquote","unquote-splicing","unreduced","unsigned-bit-shift-right","update","update-in","update-proxy","uri?","use","uuid?","val","vals","var-get","var-set","var?","vary-meta","vec","vector","vector-of","vector?","volatile!","volatile?","vreset!","vswap!","when","when-first","when-let","when-not","when-some","while","with-bindings","with-bindings*","with-in-str","with-loading-context","with-local-vars","with-meta","with-open","with-out-str","with-precision","with-redefs","with-redefs-fn","xml-seq","zero?","zipmap"],tokenizer:{root:[{include:"@whitespace"},[/@numbers/,"number"],[/@characters/,"string"],{include:"@string"},[/[()\[\]{}]/,"@brackets"],[/\/#"(?:\.|(?:")|[^"\n])*"\/g/,"regexp"],[/[#'@^`~]/,"meta"],[/@qualifiedSymbols/,{cases:{"^:.+$":"constant","@specialForms":"keyword","@coreSymbols":"keyword","@constants":"constant","@default":"identifier"}}]],whitespace:[[/[\s,]+/,"white"],[/;.*$/,"comment"],[/\(comment\b/,"comment","@comment"]],comment:[[/\(/,"comment","@push"],[/\)/,"comment","@pop"],[/[^()]/,"comment"]],string:[[/"/,"string","@multiLineString"]],multiLineString:[[/"/,"string","@popall"],[/@escapes/,"string.escape"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72188.5b48f0f8.chunk.js b/ydb/core/viewer/monitoring/static/js/72188.5b48f0f8.chunk.js new file mode 100644 index 000000000000..a2c7c2402fa2 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72188.5b48f0f8.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72188],{66923:e=>{function n(e){e.languages["dns-zone-file"]={comment:/;.*/,string:{pattern:/"(?:\\.|[^"\\\r\n])*"/,greedy:!0},variable:[{pattern:/(^\$ORIGIN[ \t]+)\S+/m,lookbehind:!0},{pattern:/(^|\s)@(?=\s|$)/,lookbehind:!0}],keyword:/^\$(?:INCLUDE|ORIGIN|TTL)(?=\s|$)/m,class:{pattern:/(^|\s)(?:CH|CS|HS|IN)(?=\s|$)/,lookbehind:!0,alias:"keyword"},type:{pattern:/(^|\s)(?:A|A6|AAAA|AFSDB|APL|ATMA|CAA|CDNSKEY|CDS|CERT|CNAME|DHCID|DLV|DNAME|DNSKEY|DS|EID|GID|GPOS|HINFO|HIP|IPSECKEY|ISDN|KEY|KX|LOC|MAILA|MAILB|MB|MD|MF|MG|MINFO|MR|MX|NAPTR|NB|NBSTAT|NIMLOC|NINFO|NS|NSAP|NSAP-PTR|NSEC|NSEC3|NSEC3PARAM|NULL|NXT|OPENPGPKEY|PTR|PX|RKEY|RP|RRSIG|RT|SIG|SINK|SMIMEA|SOA|SPF|SRV|SSHFP|TA|TKEY|TLSA|TSIG|TXT|UID|UINFO|UNSPEC|URI|WKS|X25)(?=\s|$)/,lookbehind:!0,alias:"keyword"},punctuation:/[()]/},e.languages["dns-zone"]=e.languages["dns-zone-file"]}e.exports=n,n.displayName="dnsZoneFile",n.aliases=[]},72188:(e,n,S)=>{S.d(n,{default:()=>a});var N=S(66923);const a=S.n(N)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/7240.a674bc94.chunk.js b/ydb/core/viewer/monitoring/static/js/7240.a674bc94.chunk.js deleted file mode 100644 index 08745511596a..000000000000 --- a/ydb/core/viewer/monitoring/static/js/7240.a674bc94.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[7240],{17240:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),s={name:"ms-my",weekdays:"Ahad_Isnin_Selasa_Rabu_Khamis_Jumaat_Sabtu".split("_"),months:"Januari_Februari_Mac_April_Mei_Jun_Julai_Ogos_September_Oktober_November_Disember".split("_"),weekStart:1,weekdaysShort:"Ahd_Isn_Sel_Rab_Kha_Jum_Sab".split("_"),monthsShort:"Jan_Feb_Mac_Apr_Mei_Jun_Jul_Ogs_Sep_Okt_Nov_Dis".split("_"),weekdaysMin:"Ah_Is_Sl_Rb_Km_Jm_Sb".split("_"),ordinal:function(e){return e},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [pukul] HH.mm",LLLL:"dddd, D MMMM YYYY [pukul] HH.mm"},relativeTime:{future:"dalam %s",past:"%s yang lepas",s:"beberapa saat",m:"seminit",mm:"%d minit",h:"sejam",hh:"%d jam",d:"sehari",dd:"%d hari",M:"sebulan",MM:"%d bulan",y:"setahun",yy:"%d tahun"}};return _.default.locale(s,null,!0),s}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72401.bef7ab50.chunk.js b/ydb/core/viewer/monitoring/static/js/72401.bef7ab50.chunk.js new file mode 100644 index 000000000000..c60f1165ff46 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72401.bef7ab50.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72401],{33164:e=>{function r(e){e.languages.apacheconf={comment:/#.*/,"directive-inline":{pattern:/(^[\t ]*)\b(?:AcceptFilter|AcceptPathInfo|AccessFileName|Action|Add(?:Alt|AltByEncoding|AltByType|Charset|DefaultCharset|Description|Encoding|Handler|Icon|IconByEncoding|IconByType|InputFilter|Language|ModuleInfo|OutputFilter|OutputFilterByType|Type)|Alias|AliasMatch|Allow(?:CONNECT|EncodedSlashes|Methods|Override|OverrideList)?|Anonymous(?:_LogEmail|_MustGiveEmail|_NoUserID|_VerifyEmail)?|AsyncRequestWorkerFactor|Auth(?:BasicAuthoritative|BasicFake|BasicProvider|BasicUseDigestAlgorithm|DBDUserPWQuery|DBDUserRealmQuery|DBMGroupFile|DBMType|DBMUserFile|Digest(?:Algorithm|Domain|NonceLifetime|Provider|Qop|ShmemSize)|Form(?:Authoritative|Body|DisableNoStore|FakeBasicAuth|Location|LoginRequiredLocation|LoginSuccessLocation|LogoutLocation|Method|Mimetype|Password|Provider|SitePassphrase|Size|Username)|GroupFile|LDAP(?:AuthorizePrefix|BindAuthoritative|BindDN|BindPassword|CharsetConfig|CompareAsUser|CompareDNOnServer|DereferenceAliases|GroupAttribute|GroupAttributeIsDN|InitialBindAsUser|InitialBindPattern|MaxSubGroupDepth|RemoteUserAttribute|RemoteUserIsDN|SearchAsUser|SubGroupAttribute|SubGroupClass|Url)|Merging|Name|nCache(?:Context|Enable|ProvideFor|SOCache|Timeout)|nzFcgiCheckAuthnProvider|nzFcgiDefineProvider|Type|UserFile|zDBDLoginToReferer|zDBDQuery|zDBDRedirectQuery|zDBMType|zSendForbiddenOnFailure)|BalancerGrowth|BalancerInherit|BalancerMember|BalancerPersist|BrowserMatch|BrowserMatchNoCase|BufferedLogs|BufferSize|Cache(?:DefaultExpire|DetailHeader|DirLength|DirLevels|Disable|Enable|File|Header|IgnoreCacheControl|IgnoreHeaders|IgnoreNoLastMod|IgnoreQueryString|IgnoreURLSessionIdentifiers|KeyBaseURL|LastModifiedFactor|Lock|LockMaxAge|LockPath|MaxExpire|MaxFileSize|MinExpire|MinFileSize|NegotiatedDocs|QuickHandler|ReadSize|ReadTime|Root|Socache(?:MaxSize|MaxTime|MinTime|ReadSize|ReadTime)?|StaleOnError|StoreExpired|StoreNoStore|StorePrivate)|CGIDScriptTimeout|CGIMapExtension|CharsetDefault|CharsetOptions|CharsetSourceEnc|CheckCaseOnly|CheckSpelling|ChrootDir|ContentDigest|CookieDomain|CookieExpires|CookieName|CookieStyle|CookieTracking|CoreDumpDirectory|CustomLog|Dav|DavDepthInfinity|DavGenericLockDB|DavLockDB|DavMinTimeout|DBDExptime|DBDInitSQL|DBDKeep|DBDMax|DBDMin|DBDParams|DBDPersist|DBDPrepareSQL|DBDriver|DefaultIcon|DefaultLanguage|DefaultRuntimeDir|DefaultType|Define|Deflate(?:BufferSize|CompressionLevel|FilterNote|InflateLimitRequestBody|InflateRatio(?:Burst|Limit)|MemLevel|WindowSize)|Deny|DirectoryCheckHandler|DirectoryIndex|DirectoryIndexRedirect|DirectorySlash|DocumentRoot|DTracePrivileges|DumpIOInput|DumpIOOutput|EnableExceptionHook|EnableMMAP|EnableSendfile|Error|ErrorDocument|ErrorLog|ErrorLogFormat|Example|ExpiresActive|ExpiresByType|ExpiresDefault|ExtendedStatus|ExtFilterDefine|ExtFilterOptions|FallbackResource|FileETag|FilterChain|FilterDeclare|FilterProtocol|FilterProvider|FilterTrace|ForceLanguagePriority|ForceType|ForensicLog|GprofDir|GracefulShutdownTimeout|Group|Header|HeaderName|Heartbeat(?:Address|Listen|MaxServers|Storage)|HostnameLookups|IdentityCheck|IdentityCheckTimeout|ImapBase|ImapDefault|ImapMenu|Include|IncludeOptional|Index(?:HeadInsert|Ignore|IgnoreReset|Options|OrderDefault|StyleSheet)|InputSed|ISAPI(?:AppendLogToErrors|AppendLogToQuery|CacheFile|FakeAsync|LogNotSupported|ReadAheadBuffer)|KeepAlive|KeepAliveTimeout|KeptBodySize|LanguagePriority|LDAP(?:CacheEntries|CacheTTL|ConnectionPoolTTL|ConnectionTimeout|LibraryDebug|OpCacheEntries|OpCacheTTL|ReferralHopLimit|Referrals|Retries|RetryDelay|SharedCacheFile|SharedCacheSize|Timeout|TrustedClientCert|TrustedGlobalCert|TrustedMode|VerifyServerCert)|Limit(?:InternalRecursion|Request(?:Body|Fields|FieldSize|Line)|XMLRequestBody)|Listen|ListenBackLog|LoadFile|LoadModule|LogFormat|LogLevel|LogMessage|LuaAuthzProvider|LuaCodeCache|Lua(?:Hook(?:AccessChecker|AuthChecker|CheckUserID|Fixups|InsertFilter|Log|MapToStorage|TranslateName|TypeChecker)|Inherit|InputFilter|MapHandler|OutputFilter|PackageCPath|PackagePath|QuickHandler|Root|Scope)|Max(?:ConnectionsPerChild|KeepAliveRequests|MemFree|RangeOverlaps|RangeReversals|Ranges|RequestWorkers|SpareServers|SpareThreads|Threads)|MergeTrailers|MetaDir|MetaFiles|MetaSuffix|MimeMagicFile|MinSpareServers|MinSpareThreads|MMapFile|ModemStandard|ModMimeUsePathInfo|MultiviewsMatch|Mutex|NameVirtualHost|NoProxy|NWSSLTrustedCerts|NWSSLUpgradeable|Options|Order|OutputSed|PassEnv|PidFile|PrivilegesMode|Protocol|ProtocolEcho|Proxy(?:AddHeaders|BadHeader|Block|Domain|ErrorOverride|ExpressDBMFile|ExpressDBMType|ExpressEnable|FtpDirCharset|FtpEscapeWildcards|FtpListOnWildcard|HTML(?:BufSize|CharsetOut|DocType|Enable|Events|Extended|Fixups|Interp|Links|Meta|StripComments|URLMap)|IOBufferSize|MaxForwards|Pass(?:Inherit|InterpolateEnv|Match|Reverse|ReverseCookieDomain|ReverseCookiePath)?|PreserveHost|ReceiveBufferSize|Remote|RemoteMatch|Requests|SCGIInternalRedirect|SCGISendfile|Set|SourceAddress|Status|Timeout|Via)|ReadmeName|ReceiveBufferSize|Redirect|RedirectMatch|RedirectPermanent|RedirectTemp|ReflectorHeader|RemoteIP(?:Header|InternalProxy|InternalProxyList|ProxiesHeader|TrustedProxy|TrustedProxyList)|RemoveCharset|RemoveEncoding|RemoveHandler|RemoveInputFilter|RemoveLanguage|RemoveOutputFilter|RemoveType|RequestHeader|RequestReadTimeout|Require|Rewrite(?:Base|Cond|Engine|Map|Options|Rule)|RLimitCPU|RLimitMEM|RLimitNPROC|Satisfy|ScoreBoardFile|Script(?:Alias|AliasMatch|InterpreterSource|Log|LogBuffer|LogLength|Sock)?|SecureListen|SeeRequestTail|SendBufferSize|Server(?:Admin|Alias|Limit|Name|Path|Root|Signature|Tokens)|Session(?:Cookie(?:Name|Name2|Remove)|Crypto(?:Cipher|Driver|Passphrase|PassphraseFile)|DBD(?:CookieName|CookieName2|CookieRemove|DeleteLabel|InsertLabel|PerUser|SelectLabel|UpdateLabel)|Env|Exclude|Header|Include|MaxAge)?|SetEnv|SetEnvIf|SetEnvIfExpr|SetEnvIfNoCase|SetHandler|SetInputFilter|SetOutputFilter|SSIEndTag|SSIErrorMsg|SSIETag|SSILastModified|SSILegacyExprParser|SSIStartTag|SSITimeFormat|SSIUndefinedEcho|SSL(?:CACertificateFile|CACertificatePath|CADNRequestFile|CADNRequestPath|CARevocationCheck|CARevocationFile|CARevocationPath|CertificateChainFile|CertificateFile|CertificateKeyFile|CipherSuite|Compression|CryptoDevice|Engine|FIPS|HonorCipherOrder|InsecureRenegotiation|OCSP(?:DefaultResponder|Enable|OverrideResponder|ResponderTimeout|ResponseMaxAge|ResponseTimeSkew|UseRequestNonce)|OpenSSLConfCmd|Options|PassPhraseDialog|Protocol|Proxy(?:CACertificateFile|CACertificatePath|CARevocation(?:Check|File|Path)|CheckPeer(?:CN|Expire|Name)|CipherSuite|Engine|MachineCertificate(?:ChainFile|File|Path)|Protocol|Verify|VerifyDepth)|RandomSeed|RenegBufferSize|Require|RequireSSL|Session(?:Cache|CacheTimeout|TicketKeyFile|Tickets)|SRPUnknownUserSeed|SRPVerifierFile|Stapling(?:Cache|ErrorCacheTimeout|FakeTryLater|ForceURL|ResponderTimeout|ResponseMaxAge|ResponseTimeSkew|ReturnResponderErrors|StandardCacheTimeout)|StrictSNIVHostCheck|UserName|UseStapling|VerifyClient|VerifyDepth)|StartServers|StartThreads|Substitute|Suexec|SuexecUserGroup|ThreadLimit|ThreadsPerChild|ThreadStackSize|TimeOut|TraceEnable|TransferLog|TypesConfig|UnDefine|UndefMacro|UnsetEnv|Use|UseCanonicalName|UseCanonicalPhysicalPort|User|UserDir|VHostCGIMode|VHostCGIPrivs|VHostGroup|VHostPrivs|VHostSecure|VHostUser|Virtual(?:DocumentRoot|ScriptAlias)(?:IP)?|WatchdogInterval|XBitHack|xml2EncAlias|xml2EncDefault|xml2StartParse)\b/im,lookbehind:!0,alias:"property"},"directive-block":{pattern:/<\/?\b(?:Auth[nz]ProviderAlias|Directory|DirectoryMatch|Else|ElseIf|Files|FilesMatch|If|IfDefine|IfModule|IfVersion|Limit|LimitExcept|Location|LocationMatch|Macro|Proxy|Require(?:All|Any|None)|VirtualHost)\b.*>/i,inside:{"directive-block":{pattern:/^<\/?\w+/,inside:{punctuation:/^<\/?/},alias:"tag"},"directive-block-parameter":{pattern:/.*[^>]/,inside:{punctuation:/:/,string:{pattern:/("|').*\1/,inside:{variable:/[$%]\{?(?:\w\.?[-+:]?)+\}?/}}},alias:"attr-value"},punctuation:/>/},alias:"tag"},"directive-flags":{pattern:/\[(?:[\w=],?)+\]/,alias:"keyword"},string:{pattern:/("|').*\1/,inside:{variable:/[$%]\{?(?:\w\.?[-+:]?)+\}?/}},variable:/[$%]\{?(?:\w\.?[-+:]?)+\}?/,regex:/\^?.*\$|\^.*\$?/}}e.exports=r,r.displayName="apacheconf",r.aliases=[]},72401:(e,r,i)=>{i.d(r,{default:()=>a});var t=i(33164);const a=i.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72568.9f8b7a4b.chunk.js b/ydb/core/viewer/monitoring/static/js/72568.9f8b7a4b.chunk.js new file mode 100644 index 000000000000..a04b7cd30bd0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72568.9f8b7a4b.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72568],{72568:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),n={1:"\u09e7",2:"\u09e8",3:"\u09e9",4:"\u09ea",5:"\u09eb",6:"\u09ec",7:"\u09ed",8:"\u09ee",9:"\u09ef",0:"\u09e6"},r={"\u09e7":"1","\u09e8":"2","\u09e9":"3","\u09ea":"4","\u09eb":"5","\u09ec":"6","\u09ed":"7","\u09ee":"8","\u09ef":"9","\u09e6":"0"},d={name:"bn-bd",weekdays:"\u09b0\u09ac\u09bf\u09ac\u09be\u09b0_\u09b8\u09cb\u09ae\u09ac\u09be\u09b0_\u09ae\u0999\u09cd\u0997\u09b2\u09ac\u09be\u09b0_\u09ac\u09c1\u09a7\u09ac\u09be\u09b0_\u09ac\u09c3\u09b9\u09b8\u09cd\u09aa\u09a4\u09bf\u09ac\u09be\u09b0_\u09b6\u09c1\u0995\u09cd\u09b0\u09ac\u09be\u09b0_\u09b6\u09a8\u09bf\u09ac\u09be\u09b0".split("_"),months:"\u099c\u09be\u09a8\u09c1\u09df\u09be\u09b0\u09bf_\u09ab\u09c7\u09ac\u09cd\u09b0\u09c1\u09df\u09be\u09b0\u09bf_\u09ae\u09be\u09b0\u09cd\u099a_\u098f\u09aa\u09cd\u09b0\u09bf\u09b2_\u09ae\u09c7_\u099c\u09c1\u09a8_\u099c\u09c1\u09b2\u09be\u0987_\u0986\u0997\u09b8\u09cd\u099f_\u09b8\u09c7\u09aa\u09cd\u099f\u09c7\u09ae\u09cd\u09ac\u09b0_\u0985\u0995\u09cd\u099f\u09cb\u09ac\u09b0_\u09a8\u09ad\u09c7\u09ae\u09cd\u09ac\u09b0_\u09a1\u09bf\u09b8\u09c7\u09ae\u09cd\u09ac\u09b0".split("_"),weekdaysShort:"\u09b0\u09ac\u09bf_\u09b8\u09cb\u09ae_\u09ae\u0999\u09cd\u0997\u09b2_\u09ac\u09c1\u09a7_\u09ac\u09c3\u09b9\u09b8\u09cd\u09aa\u09a4\u09bf_\u09b6\u09c1\u0995\u09cd\u09b0_\u09b6\u09a8\u09bf".split("_"),monthsShort:"\u099c\u09be\u09a8\u09c1_\u09ab\u09c7\u09ac\u09cd\u09b0\u09c1_\u09ae\u09be\u09b0\u09cd\u099a_\u098f\u09aa\u09cd\u09b0\u09bf\u09b2_\u09ae\u09c7_\u099c\u09c1\u09a8_\u099c\u09c1\u09b2\u09be\u0987_\u0986\u0997\u09b8\u09cd\u099f_\u09b8\u09c7\u09aa\u09cd\u099f_\u0985\u0995\u09cd\u099f\u09cb_\u09a8\u09ad\u09c7_\u09a1\u09bf\u09b8\u09c7".split("_"),weekdaysMin:"\u09b0\u09ac\u09bf_\u09b8\u09cb\u09ae_\u09ae\u0999\u09cd\u0997_\u09ac\u09c1\u09a7_\u09ac\u09c3\u09b9\u0983_\u09b6\u09c1\u0995\u09cd\u09b0_\u09b6\u09a8\u09bf".split("_"),weekStart:0,preparse:function(_){return _.replace(/[\u09e7\u09e8\u09e9\u09ea\u09eb\u09ec\u09ed\u09ee\u09ef\u09e6]/g,(function(_){return r[_]}))},postformat:function(_){return _.replace(/\d/g,(function(_){return n[_]}))},ordinal:function(_){var e=["\u0987","\u09b2\u09be","\u09b0\u09be","\u09a0\u09be","\u09b6\u09c7"],t=_%100;return"["+_+(e[(t-20)%10]||e[t]||e[0])+"]"},formats:{LT:"A h:mm \u09b8\u09ae\u09df",LTS:"A h:mm:ss \u09b8\u09ae\u09df",L:"DD/MM/YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6",LL:"D MMMM YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6",LLL:"D MMMM YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6, A h:mm \u09b8\u09ae\u09df",LLLL:"dddd, D MMMM YYYY \u0996\u09cd\u09b0\u09bf\u09b8\u09cd\u099f\u09be\u09ac\u09cd\u09a6, A h:mm \u09b8\u09ae\u09df"},meridiem:function(_){return _<4?"\u09b0\u09be\u09a4":_<6?"\u09ad\u09cb\u09b0":_<12?"\u09b8\u0995\u09be\u09b2":_<15?"\u09a6\u09c1\u09aa\u09c1\u09b0":_<18?"\u09ac\u09bf\u0995\u09be\u09b2":_<20?"\u09b8\u09a8\u09cd\u09a7\u09cd\u09af\u09be":"\u09b0\u09be\u09a4"},relativeTime:{future:"%s \u09aa\u09b0\u09c7",past:"%s \u0986\u0997\u09c7",s:"\u0995\u09df\u09c7\u0995 \u09b8\u09c7\u0995\u09c7\u09a8\u09cd\u09a1",m:"\u098f\u0995 \u09ae\u09bf\u09a8\u09bf\u099f",mm:"%d \u09ae\u09bf\u09a8\u09bf\u099f",h:"\u098f\u0995 \u0998\u09a8\u09cd\u099f\u09be",hh:"%d \u0998\u09a8\u09cd\u099f\u09be",d:"\u098f\u0995 \u09a6\u09bf\u09a8",dd:"%d \u09a6\u09bf\u09a8",M:"\u098f\u0995 \u09ae\u09be\u09b8",MM:"%d \u09ae\u09be\u09b8",y:"\u098f\u0995 \u09ac\u099b\u09b0",yy:"%d \u09ac\u099b\u09b0"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72737.e79b7900.chunk.js b/ydb/core/viewer/monitoring/static/js/72737.e79b7900.chunk.js new file mode 100644 index 000000000000..bf8d81d3ff9e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72737.e79b7900.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72737],{72737:(e,o,t)=>{t.d(o,{default:()=>a});var i=t(84358);const a=t.n(i)()},84358:e=>{function o(e){e.languages.gamemakerlanguage=e.languages.gml=e.languages.extend("clike",{keyword:/\b(?:break|case|continue|default|do|else|enum|exit|for|globalvar|if|repeat|return|switch|until|var|while)\b/,number:/(?:\b0x[\da-f]+|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?)[ulf]{0,4}/i,operator:/--|\+\+|[-+%/=]=?|!=|\*\*?=?|<[<=>]?|>[=>]?|&&?|\^\^?|\|\|?|~|\b(?:and|at|not|or|with|xor)\b/,constant:/\b(?:GM_build_date|GM_version|action_(?:continue|restart|reverse|stop)|all|gamespeed_(?:fps|microseconds)|global|local|noone|other|pi|pointer_(?:invalid|null)|self|timezone_(?:local|utc)|undefined|ev_(?:create|destroy|step|alarm|keyboard|mouse|collision|other|draw|draw_(?:begin|end|post|pre)|keypress|keyrelease|trigger|(?:left|middle|no|right)_button|(?:left|middle|right)_press|(?:left|middle|right)_release|mouse_(?:enter|leave|wheel_down|wheel_up)|global_(?:left|middle|right)_button|global_(?:left|middle|right)_press|global_(?:left|middle|right)_release|joystick(?:1|2)_(?:button1|button2|button3|button4|button5|button6|button7|button8|down|left|right|up)|outside|boundary|game_start|game_end|room_start|room_end|no_more_lives|animation_end|end_of_path|no_more_health|user\d|gui|gui_begin|gui_end|step_(?:begin|end|normal))|vk_(?:alt|anykey|backspace|control|delete|down|end|enter|escape|home|insert|left|nokey|pagedown|pageup|pause|printscreen|return|right|shift|space|tab|up|f\d|numpad\d|add|decimal|divide|lalt|lcontrol|lshift|multiply|ralt|rcontrol|rshift|subtract)|achievement_(?:filter_(?:all_players|favorites_only|friends_only)|friends_info|info|leaderboard_info|our_info|pic_loaded|show_(?:achievement|bank|friend_picker|leaderboard|profile|purchase_prompt|ui)|type_challenge|type_score_challenge)|asset_(?:font|object|path|room|script|shader|sound|sprite|tiles|timeline|unknown)|audio_(?:3d|falloff_(?:exponent_distance|exponent_distance_clamped|inverse_distance|inverse_distance_clamped|linear_distance|linear_distance_clamped|none)|mono|new_system|old_system|stereo)|bm_(?:add|complex|dest_alpha|dest_color|dest_colour|inv_dest_alpha|inv_dest_color|inv_dest_colour|inv_src_alpha|inv_src_color|inv_src_colour|max|normal|one|src_alpha|src_alpha_sat|src_color|src_colour|subtract|zero)|browser_(?:chrome|firefox|ie|ie_mobile|not_a_browser|opera|safari|safari_mobile|tizen|unknown|windows_store)|buffer_(?:bool|f16|f32|f64|fast|fixed|generalerror|grow|invalidtype|network|outofbounds|outofspace|s16|s32|s8|seek_end|seek_relative|seek_start|string|text|u16|u32|u64|u8|vbuffer|wrap)|c_(?:aqua|black|blue|dkgray|fuchsia|gray|green|lime|ltgray|maroon|navy|olive|orange|purple|red|silver|teal|white|yellow)|cmpfunc_(?:always|equal|greater|greaterequal|less|lessequal|never|notequal)|cr_(?:appstart|arrow|beam|cross|default|drag|handpoint|hourglass|none|size_all|size_nesw|size_ns|size_nwse|size_we|uparrow)|cull_(?:clockwise|counterclockwise|noculling)|device_(?:emulator|tablet)|device_ios_(?:ipad|ipad_retina|iphone|iphone5|iphone6|iphone6plus|iphone_retina|unknown)|display_(?:landscape|landscape_flipped|portrait|portrait_flipped)|dll_(?:cdecl|cdel|stdcall)|ds_type_(?:grid|list|map|priority|queue|stack)|ef_(?:cloud|ellipse|explosion|firework|flare|rain|ring|smoke|smokeup|snow|spark|star)|fa_(?:archive|bottom|center|directory|hidden|left|middle|readonly|right|sysfile|top|volumeid)|fb_login_(?:default|fallback_to_webview|forcing_safari|forcing_webview|no_fallback_to_webview|use_system_account)|iap_(?:available|canceled|ev_consume|ev_product|ev_purchase|ev_restore|ev_storeload|failed|purchased|refunded|status_available|status_loading|status_processing|status_restoring|status_unavailable|status_uninitialised|storeload_failed|storeload_ok|unavailable)|leaderboard_type_(?:number|time_mins_secs)|lighttype_(?:dir|point)|matrix_(?:projection|view|world)|mb_(?:any|left|middle|none|right)|network_(?:config_(?:connect_timeout|disable_reliable_udp|enable_reliable_udp|use_non_blocking_socket)|socket_(?:bluetooth|tcp|udp)|type_(?:connect|data|disconnect|non_blocking_connect))|of_challenge_(?:lose|tie|win)|os_(?:android|ios|linux|macosx|ps3|ps4|psvita|unknown|uwp|win32|win8native|windows|winphone|xboxone)|phy_debug_render_(?:aabb|collision_pairs|coms|core_shapes|joints|obb|shapes)|phy_joint_(?:anchor_1_x|anchor_1_y|anchor_2_x|anchor_2_y|angle|angle_limits|damping_ratio|frequency|length_1|length_2|lower_angle_limit|max_force|max_length|max_motor_force|max_motor_torque|max_torque|motor_force|motor_speed|motor_torque|reaction_force_x|reaction_force_y|reaction_torque|speed|translation|upper_angle_limit)|phy_particle_data_flag_(?:category|color|colour|position|typeflags|velocity)|phy_particle_flag_(?:colormixing|colourmixing|elastic|powder|spring|tensile|viscous|wall|water|zombie)|phy_particle_group_flag_(?:rigid|solid)|pr_(?:linelist|linestrip|pointlist|trianglefan|trianglelist|trianglestrip)|ps_(?:distr|shape)_(?:diamond|ellipse|gaussian|invgaussian|line|linear|rectangle)|pt_shape_(?:circle|cloud|disk|explosion|flare|line|pixel|ring|smoke|snow|spark|sphere|square|star)|ty_(?:real|string)|gp_(?:face\d|axislh|axislv|axisrh|axisrv|padd|padl|padr|padu|select|shoulderl|shoulderlb|shoulderr|shoulderrb|start|stickl|stickr)|lb_disp_(?:none|numeric|time_ms|time_sec)|lb_sort_(?:ascending|descending|none)|ov_(?:achievements|community|friends|gamegroup|players|settings)|ugc_(?:filetype_(?:community|microtrans)|list_(?:Favorited|Followed|Published|Subscribed|UsedOrPlayed|VotedDown|VotedOn|VotedUp|WillVoteLater)|match_(?:AllGuides|Artwork|Collections|ControllerBindings|IntegratedGuides|Items|Items_Mtx|Items_ReadyToUse|Screenshots|UsableInGame|Videos|WebGuides)|query_(?:AcceptedForGameRankedByAcceptanceDate|CreatedByFriendsRankedByPublicationDate|FavoritedByFriendsRankedByPublicationDate|NotYetRated)|query_RankedBy(?:NumTimesReported|PublicationDate|TextSearch|TotalVotesAsc|Trend|Vote|VotesUp)|result_success|sortorder_CreationOrder(?:Asc|Desc)|sortorder_(?:ForModeration|LastUpdatedDesc|SubscriptionDateDesc|TitleAsc|VoteScoreDesc)|visibility_(?:friends_only|private|public))|vertex_usage_(?:binormal|blendindices|blendweight|color|colour|depth|fog|normal|position|psize|sample|tangent|texcoord|textcoord)|vertex_type_(?:float\d|color|colour|ubyte4)|input_type|layerelementtype_(?:background|instance|oldtilemap|particlesystem|sprite|tile|tilemap|undefined)|se_(?:chorus|compressor|echo|equalizer|flanger|gargle|none|reverb)|text_type|tile_(?:flip|index_mask|mirror|rotate)|(?:obj|rm|scr|spr)\w+)\b/,variable:/\b(?:alarm|application_surface|async_load|background_(?:alpha|blend|color|colour|foreground|height|hspeed|htiled|index|showcolor|showcolour|visible|vspeed|vtiled|width|x|xscale|y|yscale)|bbox_(?:bottom|left|right|top)|browser_(?:height|width)|caption_(?:health|lives|score)|current_(?:day|hour|minute|month|second|time|weekday|year)|cursor_sprite|debug_mode|delta_time|direction|display_aa|error_(?:last|occurred)|event_(?:action|number|object|type)|fps|fps_real|friction|game_(?:display|project|save)_(?:id|name)|gamemaker_(?:pro|registered|version)|gravity|gravity_direction|(?:h|v)speed|health|iap_data|id|image_(?:alpha|angle|blend|depth|index|number|speed|xscale|yscale)|instance_(?:count|id)|keyboard_(?:key|lastchar|lastkey|string)|layer|lives|mask_index|mouse_(?:button|lastbutton|x|y)|object_index|os_(?:browser|device|type|version)|path_(?:endaction|index|orientation|position|positionprevious|scale|speed)|persistent|phy_(?:rotation|(?:col_normal|collision|com|linear_velocity|position|speed)_(?:x|y)|angular_(?:damping|velocity)|position_(?:x|y)previous|speed|linear_damping|bullet|fixed_rotation|active|mass|inertia|dynamic|kinematic|sleeping|collision_points)|pointer_(?:invalid|null)|room|room_(?:caption|first|height|last|persistent|speed|width)|score|secure_mode|show_(?:health|lives|score)|solid|speed|sprite_(?:height|index|width|xoffset|yoffset)|temp_directory|timeline_(?:index|loop|position|running|speed)|transition_(?:color|kind|steps)|undefined|view_(?:angle|current|enabled|(?:h|v)(?:border|speed)|(?:h|w|x|y)port|(?:h|w|x|y)view|object|surface_id|visible)|visible|webgl_enabled|working_directory|(?:x|y)(?:previous|start)|x|y|argument(?:_relitive|_count|\d)|argument|global|local|other|self)\b/})}e.exports=o,o.displayName="gml",o.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72775.0e6824d4.chunk.js b/ydb/core/viewer/monitoring/static/js/72775.0e6824d4.chunk.js new file mode 100644 index 000000000000..0f7e778a7aff --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72775.0e6824d4.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72775],{72775:function(a,_,e){a.exports=function(a){"use strict";function _(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var e=_(a),t={name:"tr",weekdays:"Pazar_Pazartesi_Sal\u0131_\xc7ar\u015famba_Per\u015fembe_Cuma_Cumartesi".split("_"),weekdaysShort:"Paz_Pts_Sal_\xc7ar_Per_Cum_Cts".split("_"),weekdaysMin:"Pz_Pt_Sa_\xc7a_Pe_Cu_Ct".split("_"),months:"Ocak_\u015eubat_Mart_Nisan_May\u0131s_Haziran_Temmuz_A\u011fustos_Eyl\xfcl_Ekim_Kas\u0131m_Aral\u0131k".split("_"),monthsShort:"Oca_\u015eub_Mar_Nis_May_Haz_Tem_A\u011fu_Eyl_Eki_Kas_Ara".split("_"),weekStart:1,formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s sonra",past:"%s \xf6nce",s:"birka\xe7 saniye",m:"bir dakika",mm:"%d dakika",h:"bir saat",hh:"%d saat",d:"bir g\xfcn",dd:"%d g\xfcn",M:"bir ay",MM:"%d ay",y:"bir y\u0131l",yy:"%d y\u0131l"},ordinal:function(a){return a+"."}};return e.default.locale(t,null,!0),t}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/72788.d00f6565.chunk.js b/ydb/core/viewer/monitoring/static/js/72788.d00f6565.chunk.js new file mode 100644 index 000000000000..5576f7509ffe --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/72788.d00f6565.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[72788],{72788:(e,a,t)=>{t.d(a,{default:()=>n});var r=t(98045);const n=t.n(r)()},98045:e=>{function a(e){e.languages.oz={comment:{pattern:/\/\*[\s\S]*?\*\/|%.*/,greedy:!0},string:{pattern:/"(?:[^"\\]|\\[\s\S])*"/,greedy:!0},atom:{pattern:/'(?:[^'\\]|\\[\s\S])*'/,greedy:!0,alias:"builtin"},keyword:/\$|\[\]|\b(?:_|at|attr|case|catch|choice|class|cond|declare|define|dis|else(?:case|if)?|end|export|fail|false|feat|finally|from|fun|functor|if|import|in|local|lock|meth|nil|not|of|or|prepare|proc|prop|raise|require|self|skip|then|thread|true|try|unit)\b/,function:[/\b[a-z][A-Za-z\d]*(?=\()/,{pattern:/(\{)[A-Z][A-Za-z\d]*\b/,lookbehind:!0}],number:/\b(?:0[bx][\da-f]+|\d+(?:\.\d*)?(?:e~?\d+)?)\b|&(?:[^\\]|\\(?:\d{3}|.))/i,variable:/`(?:[^`\\]|\\.)+`/,"attr-name":/\b\w+(?=[ \t]*:(?![:=]))/,operator:/:(?:=|::?)|<[-:=]?|=(?:=|=?:?|\\=:?|!!?|[|#+\-*\/,~^@]|\b(?:andthen|div|mod|orelse)\b/,punctuation:/[\[\](){}.:;?]/}}e.exports=a,a.displayName="oz",a.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/730.a22f6f5f.chunk.js b/ydb/core/viewer/monitoring/static/js/730.a22f6f5f.chunk.js deleted file mode 100644 index 667d51a102b0..000000000000 --- a/ydb/core/viewer/monitoring/static/js/730.a22f6f5f.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[730],{40730:function(e){e.exports=function(){"use strict";return{name:"en",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),ordinal:function(e){var _=["th","st","nd","rd"],a=e%100;return"["+e+(_[(a-20)%10]||_[a]||_[0])+"]"}}}()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/73026.ba38cd34.chunk.js b/ydb/core/viewer/monitoring/static/js/73026.ba38cd34.chunk.js new file mode 100644 index 000000000000..16800c1c51bc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/73026.ba38cd34.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[73026],{42207:e=>{function a(e){!function(e){e.languages.diff={coord:[/^(?:\*{3}|-{3}|\+{3}).*$/m,/^@@.*@@$/m,/^\d.*$/m]};var a={"deleted-sign":"-","deleted-arrow":"<","inserted-sign":"+","inserted-arrow":">",unchanged:" ",diff:"!"};Object.keys(a).forEach((function(d){var n=a[d],i=[];/^\w+$/.test(d)||i.push(/\w+/.exec(d)[0]),"diff"===d&&i.push("bold"),e.languages.diff[d]={pattern:RegExp("^(?:["+n+"].*(?:\r\n?|\n|(?![\\s\\S])))+","m"),alias:i,inside:{line:{pattern:/(.)(?=[\s\S]).*(?:\r\n?|\n)?/,lookbehind:!0},prefix:{pattern:/[\s\S]/,alias:/\w+/.exec(d)[0]}}}})),Object.defineProperty(e.languages.diff,"PREFIXES",{value:a})}(e)}e.exports=a,a.displayName="diff",a.aliases=[]},73026:(e,a,d)=>{d.d(a,{default:()=>i});var n=d(42207);const i=d.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/73064.b0c26084.chunk.js b/ydb/core/viewer/monitoring/static/js/73064.b0c26084.chunk.js new file mode 100644 index 000000000000..7d76df97e8dc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/73064.b0c26084.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[73064],{73064:(a,n,t)=>{t.d(n,{default:()=>s});var e=t(83441);const s=t.n(e)()},83441:a=>{function n(a){a.languages.antlr4={comment:/\/\/.*|\/\*[\s\S]*?(?:\*\/|$)/,string:{pattern:/'(?:\\.|[^\\'\r\n])*'/,greedy:!0},"character-class":{pattern:/\[(?:\\.|[^\\\]\r\n])*\]/,greedy:!0,alias:"regex",inside:{range:{pattern:/([^[]|(?:^|[^\\])(?:\\\\)*\\\[)-(?!\])/,lookbehind:!0,alias:"punctuation"},escape:/\\(?:u(?:[a-fA-F\d]{4}|\{[a-fA-F\d]+\})|[pP]\{[=\w-]+\}|[^\r\nupP])/,punctuation:/[\[\]]/}},action:{pattern:/\{(?:[^{}]|\{(?:[^{}]|\{(?:[^{}]|\{[^{}]*\})*\})*\})*\}/,greedy:!0,inside:{content:{pattern:/(\{)[\s\S]+(?=\})/,lookbehind:!0},punctuation:/[{}]/}},command:{pattern:/(->\s*(?!\s))(?:\s*(?:,\s*)?\b[a-z]\w*(?:\s*\([^()\r\n]*\))?)+(?=\s*;)/i,lookbehind:!0,inside:{function:/\b\w+(?=\s*(?:[,(]|$))/,punctuation:/[,()]/}},annotation:{pattern:/@\w+(?:::\w+)*/,alias:"keyword"},label:{pattern:/#[ \t]*\w+/,alias:"punctuation"},keyword:/\b(?:catch|channels|finally|fragment|grammar|import|lexer|locals|mode|options|parser|returns|throws|tokens)\b/,definition:[{pattern:/\b[a-z]\w*(?=\s*:)/,alias:["rule","class-name"]},{pattern:/\b[A-Z]\w*(?=\s*:)/,alias:["token","constant"]}],constant:/\b[A-Z][A-Z_]*\b/,operator:/\.\.|->|[|~]|[*+?]\??/,punctuation:/[;:()=]/},a.languages.g4=a.languages.antlr4}a.exports=n,n.displayName="antlr4",n.aliases=["g4"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/73238.abca2b52.chunk.js b/ydb/core/viewer/monitoring/static/js/73238.abca2b52.chunk.js new file mode 100644 index 000000000000..41e6e7bc68b6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/73238.abca2b52.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[73238],{73238:(e,t,C)=>{C.r(t),C.d(t,{ReactComponent:()=>u,default:()=>E});var r,a,n,o,i,l,s,d,c,H,p,V,k,M=C(59284);function h(){return h=Object.assign?Object.assign.bind():function(e){for(var t=1;t{t.r(l),t.d(l,{ReactComponent:()=>b,default:()=>M});var c,a,h,v,m,n,z,d,i,r,f,s,o,p=t(59284);function E(){return E=Object.assign?Object.assign.bind():function(e){for(var l=1;l{n.d(t,{A:()=>o});var l=n(59284);const o=e=>l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),l.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 1.5a6.5 6.5 0 1 1-6.445 7.348.75.75 0 1 1 1.487-.194A5.001 5.001 0 1 0 4.43 4.5h1.32a.75.75 0 0 1 0 1.5h-3A.75.75 0 0 1 2 5.25v-3a.75.75 0 0 1 1.5 0v1.06A6.48 6.48 0 0 1 8 1.5",clipRule:"evenodd"}))},18677:(e,t,n)=>{n.d(t,{A:()=>o});var l=n(59284);const o=e=>l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),l.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},66528:(e,t,n)=>{n.d(t,{A:()=>o});var l=n(59284);const o=e=>l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),l.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M4.5 1.5a3 3 0 0 0-3 3v7a3 3 0 0 0 3 3h7a3 3 0 0 0 3-3v-7a3 3 0 0 0-3-3z",clipRule:"evenodd"}))},5874:(e,t,n)=>{n.d(t,{W:()=>L});var l=n(59284);const o=e=>{if(e.options.enableRowSelection)return Boolean(e.options.enableMultiRowSelection)};var r=n(32084);const i=l.createContext(void 0),a={};var s=n(85720);const u=e=>{const t=e.column.getIsPinned(),n="left"===t,l="right"===t,o=n&&e.column.getIsLastColumn("left"),r=l&&e.column.getIsFirstColumn("right");return{pinned:Boolean(t),"pinned-left":n,"pinned-right":l,"last-pinned-left":o,"first-pinned-right":r}},d=e=>e?Object.assign({id:e.column.id},u(e)):null,g=(e,t)=>{if(!e)return t;const n=e.column.getIsPinned();return Object.assign({width:e.column.getSize(),minWidth:e.column.columnDef.minSize,maxWidth:e.column.columnDef.maxSize,left:"left"===n?`${e.column.getStart("left")}px`:void 0,right:"right"===n?`${e.column.getAfter("right")}px`:void 0},t)};var c=n(82435);(0,c.withNaming)({e:"__",m:"_"});const p=(0,c.withNaming)({n:"gt-",e:"__",m:"_"}),m=p("table");var f=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{cell:t,children:n,className:o,style:r,attributes:i}=e,a=f(e,["cell","children","className","style","attributes"]);const u="function"===typeof i?i(t):i,c="function"===typeof o?o(t):o;return l.createElement("td",Object.assign({className:m("cell",d(t),c)},a,u,{style:g(t,Object.assign(Object.assign({},r),null===u||void 0===u?void 0:u.style))}),t?(0,s.Kv)(t.column.columnDef.cell,t.getContext()):n)},w=p("group-header"),h=({row:e,className:t,getGroupTitle:n})=>{var o;return l.createElement("h2",{className:w(null,t)},l.createElement("button",{className:w("button"),onClick:e.getToggleExpandedHandler()},l.createElement("svg",{className:w("icon",{expanded:e.getIsExpanded()}),viewBox:"0 0 16 16",width:"16",height:"16"},l.createElement("path",{d:"M2.97 5.47a.75.75 0 0 1 1.06 0L8 9.44l3.97-3.97a.75.75 0 1 1 1.06 1.06l-4.5 4.5a.75.75 0 0 1-1.06 0l-4.5-4.5a.75.75 0 0 1 0-1.06Z",fill:"currentColor"})),l.createElement("span",{className:w("content")},l.createElement("span",{className:w("title")},null!==(o=null===n||void 0===n?void 0:n(e))&&void 0!==o?o:e.id),l.createElement("span",{className:w("total")},e.subRows.length))))};var b=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{cellClassName:n,className:o,getGroupTitle:i,getIsCustomRow:a,getIsGroupHeaderRow:s,groupHeaderClassName:u,onClick:d,renderCustomRowContent:g,renderGroupHeader:c,renderGroupHeaderRowContent:p,row:f,rowVirtualizer:w,style:C,virtualItem:S,attributes:R,cellAttributes:y,table:I}=e,x=b(e,["cellClassName","className","getGroupTitle","getIsCustomRow","getIsGroupHeaderRow","groupHeaderClassName","onClick","renderCustomRowContent","renderGroupHeader","renderGroupHeaderRowContent","row","rowVirtualizer","style","virtualItem","attributes","cellAttributes","table"]);const M=(0,r.N)(null===w||void 0===w?void 0:w.measureElement,t),F="function"===typeof R?R(f):R,P="function"===typeof o?o(f):o,E=l.useCallback((e=>{null===d||void 0===d||d(f,e)}),[d,f]);return l.createElement("tr",Object.assign({ref:M,className:m("row",{selected:f.getIsSelected(),interactive:Boolean(d)},P),onClick:E,"data-index":null===S||void 0===S?void 0:S.index},x,F,{style:Object.assign(Object.assign({top:w&&S?S.start-w.options.scrollMargin:void 0},C),null===F||void 0===F?void 0:F.style)}),(null===s||void 0===s?void 0:s(f))?p?p({row:f,Cell:v,cellClassName:n,getGroupTitle:i}):l.createElement(v,{className:n,colSpan:f.getVisibleCells().length,attributes:y,"aria-colindex":1},c?c({row:f,className:m("group-header",u),getGroupTitle:i}):l.createElement(h,{row:f,className:m("group-header",u),getGroupTitle:i})):(null===a||void 0===a?void 0:a(f))&&g?g({row:f,Cell:v,cellClassName:n}):f.getVisibleCells().map((e=>l.createElement(v,{key:e.id,cell:e,className:n,attributes:y,"aria-colindex":e.column.getIndex()+1}))))}));C.displayName="BaseRow";var S=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var n,{attributes:o,row:s,style:u,table:d}=e,g=S(e,["attributes","row","style","table"]);const{isChildMode:c,activeItemKey:p,targetItemIndex:m=-1,enableNesting:f,useSortable:v}=null!==(n=l.useContext(i))&&void 0!==n?n:{},{setNodeRef:w,transform:h=null,transition:b,isDragging:R=!1}=(null===v||void 0===v?void 0:v({id:s.id}))||{},y=Boolean(p),I=c&&m===s.index,x=(0,r.N)(w,t),{isFirstChild:M,depth:F}=(({row:e,table:t,isDragging:n})=>{var o,r,a,s,u;const{isChildMode:d,isParentMode:g,isNextChildMode:c,targetItemIndex:p=-1,enableNesting:m}=null!==(o=l.useContext(i))&&void 0!==o?o:{};let f=n&&-1===p,v=0;if(m)if(n&&-1!==p){const e=t.getRowModel().rows,n=null!==(a=null===(r=e[p])||void 0===r?void 0:r.depth)&&void 0!==a?a:0,l=null!==(u=null===(s=e[p+1])||void 0===s?void 0:s.depth)&&void 0!==u?u:0;if(f=l>n,f)v=l,g&&v--;else{let e=0;g?e=-1:d&&(e=1),v=(c?n:Math.min(n,l))+e}v=Math.max(0,v)}else v=f?0:e.depth;return{depth:v,isFirstChild:f}})({row:s,table:d,isDragging:R}),P=(({style:e=a,transform:t,transition:n,isDragging:o,isDragActive:r,isFirstChild:s,draggableChildRowOffset:u=32,enableNesting:d})=>{var g;const{isChildMode:c,isParentMode:p}=null!==(g=l.useContext(i))&&void 0!==g?g:{};return l.useMemo((()=>{if(!r||!t)return e;let l=0;return d&&o&&(p?l=-u:c&&!s&&(l=u)),Object.assign(Object.assign({},e),{transition:n,transform:`translate3d(${Math.max(l,0)}px, ${t.y}px, 0)`})}),[u,c,r,o,s,p,e,t,n,d])})({style:u,transform:h,transition:b,isDragging:R,isDragActive:y,isFirstChild:M,enableNesting:f}),E=l.useCallback((e=>{const t="function"===typeof o?o(e):o;return Object.assign(Object.assign({},t),{"data-key":e.id,"data-depth":F,"data-draggable":!0,"data-dragging":R,"data-drag-active":y,"data-expanded":y&&I})}),[o,F,R,y,I]);return l.createElement(C,Object.assign({ref:x,attributes:E,row:s,style:P,table:d},g))}));R.displayName="BaseDraggableRow";const y=e=>Object.assign({id:e.column.id,placeholder:e.isPlaceholder,sortable:e.column.getCanSort(),wide:e.colSpan>1},u(e)),I=({header:e,attributes:t,className:n})=>{const o="function"===typeof t?t(e):t,r="function"===typeof n?n(e):n,i=e.depth-e.column.depth;return l.createElement("th",Object.assign({className:m("footer-cell",y(e),r),colSpan:e.colSpan>1?e.colSpan:void 0,rowSpan:i>1?i:void 0},o,{style:g(e,null===o||void 0===o?void 0:o.style)}),(0,s.Kv)(e.column.columnDef.footer,e.getContext()))};var x=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{footerGroup:t,attributes:n,cellAttributes:o,cellClassName:r,className:i}=e,a=x(e,["footerGroup","attributes","cellAttributes","cellClassName","className"]);const s="function"===typeof n?n(t):n,u="function"===typeof i?i(t):i;return l.createElement("tr",Object.assign({className:m("footer-row",u)},a,s),t.headers.map((e=>(e=>!e.isPlaceholder)(e)?l.createElement(I,{key:e.column.id,header:e,attributes:o,className:r}):null)))},F=e=>{if(e)return"asc"===e?"ascending":"descending"},P=e=>e.headerGroup.headers.slice(0,e.index).reduce(((e,t)=>e+t.colSpan),1),E=p("resize-handle"),V=({className:e,header:t})=>{var n;const{table:o}=t.getContext(),{columnResizeDirection:r,columnResizeMode:i}=o.options,{columnSizingInfo:a}=o.getState(),s=("rtl"===r?-1:1)*(null!==(n=a.deltaOffset)&&void 0!==n?n:0);return l.createElement("div",{className:E({direction:r,resizing:t.column.getIsResizing()},e),onDoubleClick:()=>t.column.resetSize(),onMouseDown:t.getResizeHandler(),onTouchStart:t.getResizeHandler(),style:{transform:"onEnd"===i&&t.column.getIsResizing()?`translateX(${s}px)`:void 0}})};var O=n(46734),_=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{header:t,className:n,children:o}=e,r=_(e,["header","className","children"]);const i=t.column.getToggleSortingHandler(),{onKeyDown:a}=(0,O.N)(i);return l.createElement("span",Object.assign({className:m("sort",n),role:"button",tabIndex:0,onClick:i,onKeyDown:a},r),o)},G=p("sort-indicator"),N=({className:e,header:t})=>{const n=t.column.getIsSorted();return l.createElement("span",{className:G({order:n,invisible:!n},e)},l.createElement("svg",{width:"6",height:"3",viewBox:"0 0 6 3",fill:"currentColor"},l.createElement("path",{d:"M0.404698 0C0.223319 0 0.102399 0.0887574 0.0419396 0.230769C-0.0386733 0.372781 0.00163315 0.497041 0.122552 0.60355L2.72232 2.89349C2.80293 2.9645 2.88354 3 3.00446 3C3.10523 3 3.20599 2.9645 3.28661 2.89349L5.88637 0.60355C6.00729 0.497041 6.02745 0.372781 5.96699 0.230769C5.88637 0.0887574 5.76545 0 5.60423 0H0.404698Z"})))},H=({className:e,header:t,parentHeader:n,renderHeaderCellContent:o,renderResizeHandle:r,renderSortIndicator:i,resizeHandleClassName:a,sortIndicatorClassName:u,attributes:d})=>{const c="function"===typeof d?d(t,n):d,p="function"===typeof e?e(t,n):e,f=t.isPlaceholder?t.getLeafHeaders().length:1;return l.createElement("th",Object.assign({className:m("header-cell",y(t),p),colSpan:t.colSpan>1?t.colSpan:void 0,rowSpan:f>1?f:void 0,"aria-sort":F(t.column.getIsSorted()),"aria-colindex":P(t)},c,{style:g(t,null===c||void 0===c?void 0:c.style)}),o?o({header:t}):l.createElement(l.Fragment,null,t.column.getCanSort()?l.createElement(z,{header:t},(0,s.Kv)(t.column.columnDef.header,t.getContext())," ",i?i({className:m("sort-indicator",u),header:t}):l.createElement(N,{className:m("sort-indicator",u),header:t})):(0,s.Kv)(t.column.columnDef.header,t.getContext()),t.column.getCanResize()&&(r?r({className:m("resize-handle",a),header:t}):l.createElement(V,{className:m("resize-handle",a),header:t}))))};var A=function(e,t){var n={};for(var l in e)Object.prototype.hasOwnProperty.call(e,l)&&t.indexOf(l)<0&&(n[l]=e[l]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var o=0;for(l=Object.getOwnPropertySymbols(e);o{var{cellClassName:t,className:n,headerGroup:o,parentHeaderGroup:r,renderHeaderCellContent:i,renderResizeHandle:a,renderSortIndicator:s,resizeHandleClassName:u,sortIndicatorClassName:d,attributes:g,cellAttributes:c}=e,p=A(e,["cellClassName","className","headerGroup","parentHeaderGroup","renderHeaderCellContent","renderResizeHandle","renderSortIndicator","resizeHandleClassName","sortIndicatorClassName","attributes","cellAttributes"]);const f="function"===typeof g?g(o,r):g,v="function"===typeof n?n(o,r):n;return l.createElement("tr",Object.assign({className:m("header-row",v)},p,f),o.headers.map((e=>{const n=null===r||void 0===r?void 0:r.headers.find((t=>e.column.id===t.column.id));return((e,t)=>{const n=e.isPlaceholder&&(null===t||void 0===t?void 0:t.isPlaceholder)&&t.placeholderId===e.placeholderId,l=!e.isPlaceholder&&e.id===e.column.id&&e.depth-e.column.depth>1;return!(n||l)})(e,n)?l.createElement(H,{key:e.column.id,className:t,header:e,parentHeader:n,renderHeaderCellContent:i,renderResizeHandle:a,renderSortIndicator:s,resizeHandleClassName:u,sortIndicatorClassName:d,attributes:c}):null})))},L=l.forwardRef((({table:e,attributes:t,bodyAttributes:n,bodyClassName:r,bodyRef:a,cellAttributes:s,cellClassName:u,className:d,customFooterRowCount:g,emptyContent:c,footerAttributes:p,footerCellAttributes:f,footerCellClassName:v,footerClassName:w,footerRowAttributes:h,footerRowClassName:b,getGroupTitle:S,getIsCustomRow:y,getIsGroupHeaderRow:I,groupHeaderClassName:x,headerAttributes:F,headerCellAttributes:P,headerCellClassName:E,headerClassName:V,headerRowAttributes:O,headerRowClassName:_,onRowClick:z,renderCustomFooterContent:G,renderCustomRowContent:N,renderGroupHeader:H,renderGroupHeaderRowContent:A,renderHeaderCellContent:L,renderResizeHandle:j,renderSortIndicator:T,resizeHandleClassName:B,rowAttributes:k,rowClassName:q,rowVirtualizer:$,sortIndicatorClassName:U,stickyFooter:K=!1,stickyHeader:X=!1,withFooter:Z=!1,withHeader:W=!0},J)=>{var Q;const Y=l.useContext(i),ee=null!==(Q=null===Y||void 0===Y?void 0:Y.activeItemIndex)&&void 0!==Q?Q:-1,{rows:te,rowsById:ne}=e.getRowModel(),le=l.useMemo((()=>(e=>{let t=1;return e.reduce(((e,n,l,o)=>{const r=Object.assign(Object.assign({},e),{[n.id]:t}),i=o[l+1];return(null===i||void 0===i?void 0:i.parentId)!==n.id&&(t+=n.getLeafRows().length),t++,r}),{})})(te)),[te]),oe=W?e.getHeaderGroups():[],re=Z?e.getFooterGroups():[],ie=e.getVisibleLeafColumns().length,ae=oe.length,se=Object.keys(ne).length,ue=Z&&(G&&g||re.length)||0,de=se+ae+ue,ge=(null===$||void 0===$?void 0:$.getVirtualItems())||te;return l.createElement("table",Object.assign({ref:J,className:m({"with-row-virtualization":Boolean($)},d),"data-dragging-row-index":ee>-1?ee:void 0,"aria-colcount":ie>0?ie:void 0,"aria-rowcount":de>0?de:void 0,"aria-multiselectable":o(e)},t),W&&l.createElement("thead",Object.assign({className:m("header",{sticky:X},V)},F),oe.map(((e,t)=>l.createElement(D,{key:e.id,cellClassName:E,className:_,headerGroup:e,parentHeaderGroup:oe[t-1],renderHeaderCellContent:L,renderResizeHandle:j,renderSortIndicator:T,resizeHandleClassName:B,sortIndicatorClassName:U,attributes:O,cellAttributes:P,"aria-rowindex":t+1})))),l.createElement("tbody",Object.assign({ref:a,className:m("body",r)},n,{style:Object.assign({height:ge.length?null===$||void 0===$?void 0:$.getTotalSize():void 0},null===n||void 0===n?void 0:n.style)}),ge.length?ge.map((t=>{var n;const o=$?te[t.index]:t,r=$?t:void 0,i=null!==(n=null===r||void 0===r?void 0:r.key)&&void 0!==n?n:o.id,a={cellClassName:u,className:q,getGroupTitle:S,getIsCustomRow:y,getIsGroupHeaderRow:I,groupHeaderClassName:x,attributes:k,cellAttributes:s,onClick:z,renderCustomRowContent:N,renderGroupHeader:H,renderGroupHeaderRowContent:A,row:o,rowVirtualizer:$,table:e,virtualItem:r,"aria-rowindex":ae+le[o.id],"aria-selected":e.options.enableRowSelection?o.getIsSelected():void 0};return Y?l.createElement(R,Object.assign({key:i},a)):l.createElement(C,Object.assign({key:i},a))})):(()=>{if(!c)return null;const t="function"===typeof q?q():q,n="function"===typeof u?u():u;return l.createElement("tr",{className:m("row",{empty:!0},t)},l.createElement("td",{className:m("cell",{},n),colSpan:ie,style:{width:$?e.getTotalSize():void 0}},"function"===typeof c?c():c))})()),Z&&l.createElement("tfoot",Object.assign({className:m("footer",{sticky:K},w)},p),G?G({cellClassName:m("footer-cell"),footerGroups:re,rowClassName:m("footer-row"),rowIndex:ae+se+1}):re.map(((e,t)=>(e=>e.headers.some((e=>e.column.columnDef.footer)))(e)?l.createElement(M,{key:e.id,footerGroup:e,attributes:h,cellAttributes:f,cellClassName:v,className:b,"aria-rowindex":ae+se+t+1}):null))))}));L.displayName="BaseTable"},36590:(e,t,n)=>{n.d(t,{K:()=>r});var l=n(24953),o=n(85720);const r=e=>{var t,n,r,i,a,s,u,d,g,c,p,m,f;const v=Object.assign(Object.assign({},e),{enableColumnPinning:null!==(t=e.enableColumnPinning)&&void 0!==t&&t,enableColumnResizing:null!==(n=e.enableColumnResizing)&&void 0!==n&&n,enableExpanding:null!==(r=e.enableExpanding)&&void 0!==r&&r,enableGrouping:null!==(i=e.enableGrouping)&&void 0!==i&&i,enableMultiRowSelection:null!==(a=e.enableMultiRowSelection)&&void 0!==a&&a,enableRowSelection:null!==(s=e.enableRowSelection)&&void 0!==s&&s,enableSorting:null!==(u=e.enableSorting)&&void 0!==u&&u,getCoreRowModel:null!==(d=e.getCoreRowModel)&&void 0!==d?d:(0,l.HT)(),getExpandedRowModel:e.enableExpanding?null!==(g=e.getExpandedRowModel)&&void 0!==g?g:(0,l.D0)():void 0,getGroupedRowModel:e.enableGrouping?null!==(c=e.getGroupedRowModel)&&void 0!==c?c:(0,l.cU)():void 0,getSortedRowModel:e.enableSorting?null!==(p=e.getSortedRowModel)&&void 0!==p?p:(0,l.h5)():void 0,manualGrouping:null!==(m=e.manualGrouping)&&void 0!==m&&m,manualSorting:null!==(f=e.manualSorting)&&void 0!==f&&f});return(0,o.N4)(v)}},74321:(e,t,n)=>{n.d(t,{S:()=>u});var l=n(59284),o=n(64222),r=n(46898);function i(e){return l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),l.createElement("path",{d:"M4 7h9v3H4z"}))}function a(e){return l.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),l.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const s=(0,n(69220).om)("checkbox"),u=l.forwardRef((function(e,t){const{size:n="m",indeterminate:u,disabled:d=!1,content:g,children:c,title:p,style:m,className:f,qa:v}=e,{checked:w,inputProps:h}=(0,o.v)(e),b=g||c,C=l.createElement("span",{className:s("indicator")},l.createElement("span",{className:s("icon"),"aria-hidden":!0},u?l.createElement(i,{className:s("icon-svg",{type:"dash"})}):l.createElement(a,{className:s("icon-svg",{type:"tick"})})),l.createElement("input",Object.assign({},h,{className:s("control")})),l.createElement("span",{className:s("outline")}));return l.createElement(r.m,{ref:t,title:p,style:m,size:n,disabled:d,className:s({size:n,disabled:d,indeterminate:u,checked:w},f),qa:v,control:C},b)}))},85720:(e,t,n)=>{n.d(t,{Kv:()=>r,N4:()=>i});var l=n(59284),o=n(24953);function r(e,t){return e?function(e){return"function"===typeof e&&(()=>{const t=Object.getPrototypeOf(e);return t.prototype&&t.prototype.isReactComponent})()}(n=e)||"function"===typeof n||function(e){return"object"===typeof e&&"symbol"===typeof e.$$typeof&&["react.memo","react.forward_ref"].includes(e.$$typeof.description)}(n)?l.createElement(e,t):e:null;var n}function i(e){const t={state:{},onStateChange:()=>{},renderFallbackValue:null,...e},[n]=l.useState((()=>({current:(0,o.ZR)(t)}))),[r,i]=l.useState((()=>n.current.initialState));return n.current.setOptions((t=>({...t,...e,state:{...r,...e.state},onStateChange:t=>{i(t),null==e.onStateChange||e.onStateChange(t)}}))),n.current}},24953:(e,t,n)=>{function l(e,t){return"function"===typeof e?e(t):e}function o(e,t){return n=>{t.setState((t=>({...t,[e]:l(n,t[e])})))}}function r(e){return e instanceof Function}function i(e,t){const n=[],l=e=>{e.forEach((e=>{n.push(e);const o=t(e);null!=o&&o.length&&l(o)}))};return l(e),n}function a(e,t,n){let l,o=[];return r=>{let i;n.key&&n.debug&&(i=Date.now());const a=e(r);if(!(a.length!==o.length||a.some(((e,t)=>o[t]!==e))))return l;let s;if(o=a,n.key&&n.debug&&(s=Date.now()),l=t(...a),null==n||null==n.onChange||n.onChange(l),n.key&&n.debug&&null!=n&&n.debug()){const e=Math.round(100*(Date.now()-i))/100,t=Math.round(100*(Date.now()-s))/100,l=t/16,o=(e,t)=>{for(e=String(e);e.length{var n;return null!=(n=null==e?void 0:e.debugAll)?n:e[t]},key:!1,onChange:l}}n.d(t,{D0:()=>W,HT:()=>Z,ZR:()=>X,cU:()=>Q,h5:()=>Y});const u="debugHeaders";function d(e,t,n){var l;let o={id:null!=(l=n.id)?l:t.id,column:t,index:n.index,isPlaceholder:!!n.isPlaceholder,placeholderId:n.placeholderId,depth:n.depth,subHeaders:[],colSpan:0,rowSpan:0,headerGroup:null,getLeafHeaders:()=>{const e=[],t=n=>{n.subHeaders&&n.subHeaders.length&&n.subHeaders.map(t),e.push(n)};return t(o),e},getContext:()=>({table:e,header:o,column:t})};return e._features.forEach((t=>{null==t.createHeader||t.createHeader(o,e)})),o}const g={createTable:e=>{e.getHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.left,e.getState().columnPinning.right]),((t,n,l,o)=>{var r,i;const a=null!=(r=null==l?void 0:l.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?r:[],s=null!=(i=null==o?void 0:o.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?i:[];return c(t,[...a,...n.filter((e=>!(null!=l&&l.includes(e.id))&&!(null!=o&&o.includes(e.id)))),...s],e)}),s(e.options,u)),e.getCenterHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.left,e.getState().columnPinning.right]),((t,n,l,o)=>c(t,n=n.filter((e=>!(null!=l&&l.includes(e.id))&&!(null!=o&&o.includes(e.id)))),e,"center")),s(e.options,u)),e.getLeftHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.left]),((t,n,l)=>{var o;return c(t,null!=(o=null==l?void 0:l.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?o:[],e,"left")}),s(e.options,u)),e.getRightHeaderGroups=a((()=>[e.getAllColumns(),e.getVisibleLeafColumns(),e.getState().columnPinning.right]),((t,n,l)=>{var o;return c(t,null!=(o=null==l?void 0:l.map((e=>n.find((t=>t.id===e)))).filter(Boolean))?o:[],e,"right")}),s(e.options,u)),e.getFooterGroups=a((()=>[e.getHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getLeftFooterGroups=a((()=>[e.getLeftHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getCenterFooterGroups=a((()=>[e.getCenterHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getRightFooterGroups=a((()=>[e.getRightHeaderGroups()]),(e=>[...e].reverse()),s(e.options,u)),e.getFlatHeaders=a((()=>[e.getHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getLeftFlatHeaders=a((()=>[e.getLeftHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getCenterFlatHeaders=a((()=>[e.getCenterHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getRightFlatHeaders=a((()=>[e.getRightHeaderGroups()]),(e=>e.map((e=>e.headers)).flat()),s(e.options,u)),e.getCenterLeafHeaders=a((()=>[e.getCenterFlatHeaders()]),(e=>e.filter((e=>{var t;return!(null!=(t=e.subHeaders)&&t.length)}))),s(e.options,u)),e.getLeftLeafHeaders=a((()=>[e.getLeftFlatHeaders()]),(e=>e.filter((e=>{var t;return!(null!=(t=e.subHeaders)&&t.length)}))),s(e.options,u)),e.getRightLeafHeaders=a((()=>[e.getRightFlatHeaders()]),(e=>e.filter((e=>{var t;return!(null!=(t=e.subHeaders)&&t.length)}))),s(e.options,u)),e.getLeafHeaders=a((()=>[e.getLeftHeaderGroups(),e.getCenterHeaderGroups(),e.getRightHeaderGroups()]),((e,t,n)=>{var l,o,r,i,a,s;return[...null!=(l=null==(o=e[0])?void 0:o.headers)?l:[],...null!=(r=null==(i=t[0])?void 0:i.headers)?r:[],...null!=(a=null==(s=n[0])?void 0:s.headers)?a:[]].map((e=>e.getLeafHeaders())).flat()}),s(e.options,u))}};function c(e,t,n,l){var o,r;let i=0;const a=function(e,t){void 0===t&&(t=1),i=Math.max(i,t),e.filter((e=>e.getIsVisible())).forEach((e=>{var n;null!=(n=e.columns)&&n.length&&a(e.columns,t+1)}),0)};a(e);let s=[];const u=(e,t)=>{const o={depth:t,id:[l,`${t}`].filter(Boolean).join("_"),headers:[]},r=[];e.forEach((e=>{const i=[...r].reverse()[0];let a,s=!1;if(e.column.depth===o.depth&&e.column.parent?a=e.column.parent:(a=e.column,s=!0),i&&(null==i?void 0:i.column)===a)i.subHeaders.push(e);else{const o=d(n,a,{id:[l,t,a.id,null==e?void 0:e.id].filter(Boolean).join("_"),isPlaceholder:s,placeholderId:s?`${r.filter((e=>e.column===a)).length}`:void 0,depth:t,index:r.length});o.subHeaders.push(e),r.push(o)}o.headers.push(e),e.headerGroup=o})),s.push(o),t>0&&u(r,t-1)},g=t.map(((e,t)=>d(n,e,{depth:i,index:t})));u(g,i-1),s.reverse();const c=e=>e.filter((e=>e.column.getIsVisible())).map((e=>{let t=0,n=0,l=[0];e.subHeaders&&e.subHeaders.length?(l=[],c(e.subHeaders).forEach((e=>{let{colSpan:n,rowSpan:o}=e;t+=n,l.push(o)}))):t=1;return n+=Math.min(...l),e.colSpan=t,e.rowSpan=n,{colSpan:t,rowSpan:n}}));return c(null!=(o=null==(r=s[0])?void 0:r.headers)?o:[]),s}const p=(e,t,n,l,o,r,u)=>{let d={id:t,index:l,original:n,depth:o,parentId:u,_valuesCache:{},_uniqueValuesCache:{},getValue:t=>{if(d._valuesCache.hasOwnProperty(t))return d._valuesCache[t];const n=e.getColumn(t);return null!=n&&n.accessorFn?(d._valuesCache[t]=n.accessorFn(d.original,l),d._valuesCache[t]):void 0},getUniqueValues:t=>{if(d._uniqueValuesCache.hasOwnProperty(t))return d._uniqueValuesCache[t];const n=e.getColumn(t);return null!=n&&n.accessorFn?n.columnDef.getUniqueValues?(d._uniqueValuesCache[t]=n.columnDef.getUniqueValues(d.original,l),d._uniqueValuesCache[t]):(d._uniqueValuesCache[t]=[d.getValue(t)],d._uniqueValuesCache[t]):void 0},renderValue:t=>{var n;return null!=(n=d.getValue(t))?n:e.options.renderFallbackValue},subRows:null!=r?r:[],getLeafRows:()=>i(d.subRows,(e=>e.subRows)),getParentRow:()=>d.parentId?e.getRow(d.parentId,!0):void 0,getParentRows:()=>{let e=[],t=d;for(;;){const n=t.getParentRow();if(!n)break;e.push(n),t=n}return e.reverse()},getAllCells:a((()=>[e.getAllLeafColumns()]),(t=>t.map((t=>function(e,t,n,l){const o={id:`${t.id}_${n.id}`,row:t,column:n,getValue:()=>t.getValue(l),renderValue:()=>{var t;return null!=(t=o.getValue())?t:e.options.renderFallbackValue},getContext:a((()=>[e,n,t,o]),((e,t,n,l)=>({table:e,column:t,row:n,cell:l,getValue:l.getValue,renderValue:l.renderValue})),s(e.options,"debugCells"))};return e._features.forEach((l=>{null==l.createCell||l.createCell(o,n,t,e)}),{}),o}(e,d,t,t.id)))),s(e.options,"debugRows")),_getAllCellsByColumnId:a((()=>[d.getAllCells()]),(e=>e.reduce(((e,t)=>(e[t.column.id]=t,e)),{})),s(e.options,"debugRows"))};for(let i=0;i{e._getFacetedRowModel=t.options.getFacetedRowModel&&t.options.getFacetedRowModel(t,e.id),e.getFacetedRowModel=()=>e._getFacetedRowModel?e._getFacetedRowModel():t.getPreFilteredRowModel(),e._getFacetedUniqueValues=t.options.getFacetedUniqueValues&&t.options.getFacetedUniqueValues(t,e.id),e.getFacetedUniqueValues=()=>e._getFacetedUniqueValues?e._getFacetedUniqueValues():new Map,e._getFacetedMinMaxValues=t.options.getFacetedMinMaxValues&&t.options.getFacetedMinMaxValues(t,e.id),e.getFacetedMinMaxValues=()=>{if(e._getFacetedMinMaxValues)return e._getFacetedMinMaxValues()}}},f=(e,t,n)=>{var l,o;const r=null==n||null==(l=n.toString())?void 0:l.toLowerCase();return Boolean(null==(o=e.getValue(t))||null==(o=o.toString())||null==(o=o.toLowerCase())?void 0:o.includes(r))};f.autoRemove=e=>x(e);const v=(e,t,n)=>{var l;return Boolean(null==(l=e.getValue(t))||null==(l=l.toString())?void 0:l.includes(n))};v.autoRemove=e=>x(e);const w=(e,t,n)=>{var l;return(null==(l=e.getValue(t))||null==(l=l.toString())?void 0:l.toLowerCase())===(null==n?void 0:n.toLowerCase())};w.autoRemove=e=>x(e);const h=(e,t,n)=>{var l;return null==(l=e.getValue(t))?void 0:l.includes(n)};h.autoRemove=e=>x(e)||!(null!=e&&e.length);const b=(e,t,n)=>!n.some((n=>{var l;return!(null!=(l=e.getValue(t))&&l.includes(n))}));b.autoRemove=e=>x(e)||!(null!=e&&e.length);const C=(e,t,n)=>n.some((n=>{var l;return null==(l=e.getValue(t))?void 0:l.includes(n)}));C.autoRemove=e=>x(e)||!(null!=e&&e.length);const S=(e,t,n)=>e.getValue(t)===n;S.autoRemove=e=>x(e);const R=(e,t,n)=>e.getValue(t)==n;R.autoRemove=e=>x(e);const y=(e,t,n)=>{let[l,o]=n;const r=e.getValue(t);return r>=l&&r<=o};y.resolveFilterValue=e=>{let[t,n]=e,l="number"!==typeof t?parseFloat(t):t,o="number"!==typeof n?parseFloat(n):n,r=null===t||Number.isNaN(l)?-1/0:l,i=null===n||Number.isNaN(o)?1/0:o;if(r>i){const e=r;r=i,i=e}return[r,i]},y.autoRemove=e=>x(e)||x(e[0])&&x(e[1]);const I={includesString:f,includesStringSensitive:v,equalsString:w,arrIncludes:h,arrIncludesAll:b,arrIncludesSome:C,equals:S,weakEquals:R,inNumberRange:y};function x(e){return void 0===e||null===e||""===e}const M={getDefaultColumnDef:()=>({filterFn:"auto"}),getInitialState:e=>({columnFilters:[],...e}),getDefaultOptions:e=>({onColumnFiltersChange:o("columnFilters",e),filterFromLeafRows:!1,maxLeafRowFilterDepth:100}),createColumn:(e,t)=>{e.getAutoFilterFn=()=>{const n=t.getCoreRowModel().flatRows[0],l=null==n?void 0:n.getValue(e.id);return"string"===typeof l?I.includesString:"number"===typeof l?I.inNumberRange:"boolean"===typeof l||null!==l&&"object"===typeof l?I.equals:Array.isArray(l)?I.arrIncludes:I.weakEquals},e.getFilterFn=()=>{var n,l;return r(e.columnDef.filterFn)?e.columnDef.filterFn:"auto"===e.columnDef.filterFn?e.getAutoFilterFn():null!=(n=null==(l=t.options.filterFns)?void 0:l[e.columnDef.filterFn])?n:I[e.columnDef.filterFn]},e.getCanFilter=()=>{var n,l,o;return(null==(n=e.columnDef.enableColumnFilter)||n)&&(null==(l=t.options.enableColumnFilters)||l)&&(null==(o=t.options.enableFilters)||o)&&!!e.accessorFn},e.getIsFiltered=()=>e.getFilterIndex()>-1,e.getFilterValue=()=>{var n;return null==(n=t.getState().columnFilters)||null==(n=n.find((t=>t.id===e.id)))?void 0:n.value},e.getFilterIndex=()=>{var n,l;return null!=(n=null==(l=t.getState().columnFilters)?void 0:l.findIndex((t=>t.id===e.id)))?n:-1},e.setFilterValue=n=>{t.setColumnFilters((t=>{const o=e.getFilterFn(),r=null==t?void 0:t.find((t=>t.id===e.id)),i=l(n,r?r.value:void 0);var a;if(F(o,i,e))return null!=(a=null==t?void 0:t.filter((t=>t.id!==e.id)))?a:[];const s={id:e.id,value:i};var u;return r?null!=(u=null==t?void 0:t.map((t=>t.id===e.id?s:t)))?u:[]:null!=t&&t.length?[...t,s]:[s]}))}},createRow:(e,t)=>{e.columnFilters={},e.columnFiltersMeta={}},createTable:e=>{e.setColumnFilters=t=>{const n=e.getAllLeafColumns();null==e.options.onColumnFiltersChange||e.options.onColumnFiltersChange((e=>{var o;return null==(o=l(t,e))?void 0:o.filter((e=>{const t=n.find((t=>t.id===e.id));if(t){if(F(t.getFilterFn(),e.value,t))return!1}return!0}))}))},e.resetColumnFilters=t=>{var n,l;e.setColumnFilters(t?[]:null!=(n=null==(l=e.initialState)?void 0:l.columnFilters)?n:[])},e.getPreFilteredRowModel=()=>e.getCoreRowModel(),e.getFilteredRowModel=()=>(!e._getFilteredRowModel&&e.options.getFilteredRowModel&&(e._getFilteredRowModel=e.options.getFilteredRowModel(e)),e.options.manualFiltering||!e._getFilteredRowModel?e.getPreFilteredRowModel():e._getFilteredRowModel())}};function F(e,t,n){return!(!e||!e.autoRemove)&&e.autoRemove(t,n)||"undefined"===typeof t||"string"===typeof t&&!t}const P={sum:(e,t,n)=>n.reduce(((t,n)=>{const l=n.getValue(e);return t+("number"===typeof l?l:0)}),0),min:(e,t,n)=>{let l;return n.forEach((t=>{const n=t.getValue(e);null!=n&&(l>n||void 0===l&&n>=n)&&(l=n)})),l},max:(e,t,n)=>{let l;return n.forEach((t=>{const n=t.getValue(e);null!=n&&(l=n)&&(l=n)})),l},extent:(e,t,n)=>{let l,o;return n.forEach((t=>{const n=t.getValue(e);null!=n&&(void 0===l?n>=n&&(l=o=n):(l>n&&(l=n),o{let n=0,l=0;if(t.forEach((t=>{let o=t.getValue(e);null!=o&&(o=+o)>=o&&(++n,l+=o)})),n)return l/n},median:(e,t)=>{if(!t.length)return;const n=t.map((t=>t.getValue(e)));if(l=n,!Array.isArray(l)||!l.every((e=>"number"===typeof e)))return;var l;if(1===n.length)return n[0];const o=Math.floor(n.length/2),r=n.sort(((e,t)=>e-t));return n.length%2!==0?r[o]:(r[o-1]+r[o])/2},unique:(e,t)=>Array.from(new Set(t.map((t=>t.getValue(e)))).values()),uniqueCount:(e,t)=>new Set(t.map((t=>t.getValue(e)))).size,count:(e,t)=>t.length},E={getDefaultColumnDef:()=>({aggregatedCell:e=>{var t,n;return null!=(t=null==(n=e.getValue())||null==n.toString?void 0:n.toString())?t:null},aggregationFn:"auto"}),getInitialState:e=>({grouping:[],...e}),getDefaultOptions:e=>({onGroupingChange:o("grouping",e),groupedColumnMode:"reorder"}),createColumn:(e,t)=>{e.toggleGrouping=()=>{t.setGrouping((t=>null!=t&&t.includes(e.id)?t.filter((t=>t!==e.id)):[...null!=t?t:[],e.id]))},e.getCanGroup=()=>{var n,l;return(null==(n=e.columnDef.enableGrouping)||n)&&(null==(l=t.options.enableGrouping)||l)&&(!!e.accessorFn||!!e.columnDef.getGroupingValue)},e.getIsGrouped=()=>{var n;return null==(n=t.getState().grouping)?void 0:n.includes(e.id)},e.getGroupedIndex=()=>{var n;return null==(n=t.getState().grouping)?void 0:n.indexOf(e.id)},e.getToggleGroupingHandler=()=>{const t=e.getCanGroup();return()=>{t&&e.toggleGrouping()}},e.getAutoAggregationFn=()=>{const n=t.getCoreRowModel().flatRows[0],l=null==n?void 0:n.getValue(e.id);return"number"===typeof l?P.sum:"[object Date]"===Object.prototype.toString.call(l)?P.extent:void 0},e.getAggregationFn=()=>{var n,l;if(!e)throw new Error;return r(e.columnDef.aggregationFn)?e.columnDef.aggregationFn:"auto"===e.columnDef.aggregationFn?e.getAutoAggregationFn():null!=(n=null==(l=t.options.aggregationFns)?void 0:l[e.columnDef.aggregationFn])?n:P[e.columnDef.aggregationFn]}},createTable:e=>{e.setGrouping=t=>null==e.options.onGroupingChange?void 0:e.options.onGroupingChange(t),e.resetGrouping=t=>{var n,l;e.setGrouping(t?[]:null!=(n=null==(l=e.initialState)?void 0:l.grouping)?n:[])},e.getPreGroupedRowModel=()=>e.getFilteredRowModel(),e.getGroupedRowModel=()=>(!e._getGroupedRowModel&&e.options.getGroupedRowModel&&(e._getGroupedRowModel=e.options.getGroupedRowModel(e)),e.options.manualGrouping||!e._getGroupedRowModel?e.getPreGroupedRowModel():e._getGroupedRowModel())},createRow:(e,t)=>{e.getIsGrouped=()=>!!e.groupingColumnId,e.getGroupingValue=n=>{if(e._groupingValuesCache.hasOwnProperty(n))return e._groupingValuesCache[n];const l=t.getColumn(n);return null!=l&&l.columnDef.getGroupingValue?(e._groupingValuesCache[n]=l.columnDef.getGroupingValue(e.original),e._groupingValuesCache[n]):e.getValue(n)},e._groupingValuesCache={}},createCell:(e,t,n,l)=>{e.getIsGrouped=()=>t.getIsGrouped()&&t.id===n.groupingColumnId,e.getIsPlaceholder=()=>!e.getIsGrouped()&&t.getIsGrouped(),e.getIsAggregated=()=>{var t;return!e.getIsGrouped()&&!e.getIsPlaceholder()&&!(null==(t=n.subRows)||!t.length)}}};const V={getInitialState:e=>({columnOrder:[],...e}),getDefaultOptions:e=>({onColumnOrderChange:o("columnOrder",e)}),createColumn:(e,t)=>{e.getIndex=a((e=>[H(t,e)]),(t=>t.findIndex((t=>t.id===e.id))),s(t.options,"debugColumns")),e.getIsFirstColumn=n=>{var l;return(null==(l=H(t,n)[0])?void 0:l.id)===e.id},e.getIsLastColumn=n=>{var l;const o=H(t,n);return(null==(l=o[o.length-1])?void 0:l.id)===e.id}},createTable:e=>{e.setColumnOrder=t=>null==e.options.onColumnOrderChange?void 0:e.options.onColumnOrderChange(t),e.resetColumnOrder=t=>{var n;e.setColumnOrder(t?[]:null!=(n=e.initialState.columnOrder)?n:[])},e._getOrderColumnsFn=a((()=>[e.getState().columnOrder,e.getState().grouping,e.options.groupedColumnMode]),((e,t,n)=>l=>{let o=[];if(null!=e&&e.length){const t=[...e],n=[...l];for(;n.length&&t.length;){const e=t.shift(),l=n.findIndex((t=>t.id===e));l>-1&&o.push(n.splice(l,1)[0])}o=[...o,...n]}else o=l;return function(e,t,n){if(null==t||!t.length||!n)return e;const l=e.filter((e=>!t.includes(e.id)));return"remove"===n?l:[...t.map((t=>e.find((e=>e.id===t)))).filter(Boolean),...l]}(o,t,n)}),s(e.options,"debugTable"))}},O={getInitialState:e=>({columnPinning:{left:[],right:[]},...e}),getDefaultOptions:e=>({onColumnPinningChange:o("columnPinning",e)}),createColumn:(e,t)=>{e.pin=n=>{const l=e.getLeafColumns().map((e=>e.id)).filter(Boolean);t.setColumnPinning((e=>{var t,o,r,i,a,s;return"right"===n?{left:(null!=(r=null==e?void 0:e.left)?r:[]).filter((e=>!(null!=l&&l.includes(e)))),right:[...(null!=(i=null==e?void 0:e.right)?i:[]).filter((e=>!(null!=l&&l.includes(e)))),...l]}:"left"===n?{left:[...(null!=(a=null==e?void 0:e.left)?a:[]).filter((e=>!(null!=l&&l.includes(e)))),...l],right:(null!=(s=null==e?void 0:e.right)?s:[]).filter((e=>!(null!=l&&l.includes(e))))}:{left:(null!=(t=null==e?void 0:e.left)?t:[]).filter((e=>!(null!=l&&l.includes(e)))),right:(null!=(o=null==e?void 0:e.right)?o:[]).filter((e=>!(null!=l&&l.includes(e))))}}))},e.getCanPin=()=>e.getLeafColumns().some((e=>{var n,l,o;return(null==(n=e.columnDef.enablePinning)||n)&&(null==(l=null!=(o=t.options.enableColumnPinning)?o:t.options.enablePinning)||l)})),e.getIsPinned=()=>{const n=e.getLeafColumns().map((e=>e.id)),{left:l,right:o}=t.getState().columnPinning,r=n.some((e=>null==l?void 0:l.includes(e))),i=n.some((e=>null==o?void 0:o.includes(e)));return r?"left":!!i&&"right"},e.getPinnedIndex=()=>{var n,l;const o=e.getIsPinned();return o?null!=(n=null==(l=t.getState().columnPinning)||null==(l=l[o])?void 0:l.indexOf(e.id))?n:-1:0}},createRow:(e,t)=>{e.getCenterVisibleCells=a((()=>[e._getAllVisibleCells(),t.getState().columnPinning.left,t.getState().columnPinning.right]),((e,t,n)=>{const l=[...null!=t?t:[],...null!=n?n:[]];return e.filter((e=>!l.includes(e.column.id)))}),s(t.options,"debugRows")),e.getLeftVisibleCells=a((()=>[e._getAllVisibleCells(),t.getState().columnPinning.left]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.column.id===t)))).filter(Boolean).map((e=>({...e,position:"left"})))),s(t.options,"debugRows")),e.getRightVisibleCells=a((()=>[e._getAllVisibleCells(),t.getState().columnPinning.right]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.column.id===t)))).filter(Boolean).map((e=>({...e,position:"right"})))),s(t.options,"debugRows"))},createTable:e=>{e.setColumnPinning=t=>null==e.options.onColumnPinningChange?void 0:e.options.onColumnPinningChange(t),e.resetColumnPinning=t=>{var n,l;return e.setColumnPinning(t?{left:[],right:[]}:null!=(n=null==(l=e.initialState)?void 0:l.columnPinning)?n:{left:[],right:[]})},e.getIsSomeColumnsPinned=t=>{var n;const l=e.getState().columnPinning;var o,r;return t?Boolean(null==(n=l[t])?void 0:n.length):Boolean((null==(o=l.left)?void 0:o.length)||(null==(r=l.right)?void 0:r.length))},e.getLeftLeafColumns=a((()=>[e.getAllLeafColumns(),e.getState().columnPinning.left]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.id===t)))).filter(Boolean)),s(e.options,"debugColumns")),e.getRightLeafColumns=a((()=>[e.getAllLeafColumns(),e.getState().columnPinning.right]),((e,t)=>(null!=t?t:[]).map((t=>e.find((e=>e.id===t)))).filter(Boolean)),s(e.options,"debugColumns")),e.getCenterLeafColumns=a((()=>[e.getAllLeafColumns(),e.getState().columnPinning.left,e.getState().columnPinning.right]),((e,t,n)=>{const l=[...null!=t?t:[],...null!=n?n:[]];return e.filter((e=>!l.includes(e.id)))}),s(e.options,"debugColumns"))}},_={size:150,minSize:20,maxSize:Number.MAX_SAFE_INTEGER},z={getDefaultColumnDef:()=>_,getInitialState:e=>({columnSizing:{},columnSizingInfo:{startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,isResizingColumn:!1,columnSizingStart:[]},...e}),getDefaultOptions:e=>({columnResizeMode:"onEnd",columnResizeDirection:"ltr",onColumnSizingChange:o("columnSizing",e),onColumnSizingInfoChange:o("columnSizingInfo",e)}),createColumn:(e,t)=>{e.getSize=()=>{var n,l,o;const r=t.getState().columnSizing[e.id];return Math.min(Math.max(null!=(n=e.columnDef.minSize)?n:_.minSize,null!=(l=null!=r?r:e.columnDef.size)?l:_.size),null!=(o=e.columnDef.maxSize)?o:_.maxSize)},e.getStart=a((e=>[e,H(t,e),t.getState().columnSizing]),((t,n)=>n.slice(0,e.getIndex(t)).reduce(((e,t)=>e+t.getSize()),0)),s(t.options,"debugColumns")),e.getAfter=a((e=>[e,H(t,e),t.getState().columnSizing]),((t,n)=>n.slice(e.getIndex(t)+1).reduce(((e,t)=>e+t.getSize()),0)),s(t.options,"debugColumns")),e.resetSize=()=>{t.setColumnSizing((t=>{let{[e.id]:n,...l}=t;return l}))},e.getCanResize=()=>{var n,l;return(null==(n=e.columnDef.enableResizing)||n)&&(null==(l=t.options.enableColumnResizing)||l)},e.getIsResizing=()=>t.getState().columnSizingInfo.isResizingColumn===e.id},createHeader:(e,t)=>{e.getSize=()=>{let t=0;const n=e=>{var l;e.subHeaders.length?e.subHeaders.forEach(n):t+=null!=(l=e.column.getSize())?l:0};return n(e),t},e.getStart=()=>{if(e.index>0){const t=e.headerGroup.headers[e.index-1];return t.getStart()+t.getSize()}return 0},e.getResizeHandler=n=>{const l=t.getColumn(e.column.id),o=null==l?void 0:l.getCanResize();return r=>{if(!l||!o)return;if(null==r.persist||r.persist(),N(r)&&r.touches&&r.touches.length>1)return;const i=e.getSize(),a=e?e.getLeafHeaders().map((e=>[e.column.id,e.column.getSize()])):[[l.id,l.getSize()]],s=N(r)?Math.round(r.touches[0].clientX):r.clientX,u={},d=(e,n)=>{"number"===typeof n&&(t.setColumnSizingInfo((e=>{var l,o;const r="rtl"===t.options.columnResizeDirection?-1:1,i=(n-(null!=(l=null==e?void 0:e.startOffset)?l:0))*r,a=Math.max(i/(null!=(o=null==e?void 0:e.startSize)?o:0),-.999999);return e.columnSizingStart.forEach((e=>{let[t,n]=e;u[t]=Math.round(100*Math.max(n+n*a,0))/100})),{...e,deltaOffset:i,deltaPercentage:a}})),"onChange"!==t.options.columnResizeMode&&"end"!==e||t.setColumnSizing((e=>({...e,...u}))))},g=e=>d("move",e),c=e=>{d("end",e),t.setColumnSizingInfo((e=>({...e,isResizingColumn:!1,startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,columnSizingStart:[]})))},p=n||"undefined"!==typeof document?document:null,m={moveHandler:e=>g(e.clientX),upHandler:e=>{null==p||p.removeEventListener("mousemove",m.moveHandler),null==p||p.removeEventListener("mouseup",m.upHandler),c(e.clientX)}},f={moveHandler:e=>(e.cancelable&&(e.preventDefault(),e.stopPropagation()),g(e.touches[0].clientX),!1),upHandler:e=>{var t;null==p||p.removeEventListener("touchmove",f.moveHandler),null==p||p.removeEventListener("touchend",f.upHandler),e.cancelable&&(e.preventDefault(),e.stopPropagation()),c(null==(t=e.touches[0])?void 0:t.clientX)}},v=!!function(){if("boolean"===typeof G)return G;let e=!1;try{const t={get passive(){return e=!0,!1}},n=()=>{};window.addEventListener("test",n,t),window.removeEventListener("test",n)}catch(t){e=!1}return G=e,G}()&&{passive:!1};N(r)?(null==p||p.addEventListener("touchmove",f.moveHandler,v),null==p||p.addEventListener("touchend",f.upHandler,v)):(null==p||p.addEventListener("mousemove",m.moveHandler,v),null==p||p.addEventListener("mouseup",m.upHandler,v)),t.setColumnSizingInfo((e=>({...e,startOffset:s,startSize:i,deltaOffset:0,deltaPercentage:0,columnSizingStart:a,isResizingColumn:l.id})))}}},createTable:e=>{e.setColumnSizing=t=>null==e.options.onColumnSizingChange?void 0:e.options.onColumnSizingChange(t),e.setColumnSizingInfo=t=>null==e.options.onColumnSizingInfoChange?void 0:e.options.onColumnSizingInfoChange(t),e.resetColumnSizing=t=>{var n;e.setColumnSizing(t?{}:null!=(n=e.initialState.columnSizing)?n:{})},e.resetHeaderSizeInfo=t=>{var n;e.setColumnSizingInfo(t?{startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,isResizingColumn:!1,columnSizingStart:[]}:null!=(n=e.initialState.columnSizingInfo)?n:{startOffset:null,startSize:null,deltaOffset:null,deltaPercentage:null,isResizingColumn:!1,columnSizingStart:[]})},e.getTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0},e.getLeftTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getLeftHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0},e.getCenterTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getCenterHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0},e.getRightTotalSize=()=>{var t,n;return null!=(t=null==(n=e.getRightHeaderGroups()[0])?void 0:n.headers.reduce(((e,t)=>e+t.getSize()),0))?t:0}}};let G=null;function N(e){return"touchstart"===e.type}function H(e,t){return t?"center"===t?e.getCenterVisibleLeafColumns():"left"===t?e.getLeftVisibleLeafColumns():e.getRightVisibleLeafColumns():e.getVisibleLeafColumns()}const A={getInitialState:e=>({rowSelection:{},...e}),getDefaultOptions:e=>({onRowSelectionChange:o("rowSelection",e),enableRowSelection:!0,enableMultiRowSelection:!0,enableSubRowSelection:!0}),createTable:e=>{e.setRowSelection=t=>null==e.options.onRowSelectionChange?void 0:e.options.onRowSelectionChange(t),e.resetRowSelection=t=>{var n;return e.setRowSelection(t?{}:null!=(n=e.initialState.rowSelection)?n:{})},e.toggleAllRowsSelected=t=>{e.setRowSelection((n=>{t="undefined"!==typeof t?t:!e.getIsAllRowsSelected();const l={...n},o=e.getPreGroupedRowModel().flatRows;return t?o.forEach((e=>{e.getCanSelect()&&(l[e.id]=!0)})):o.forEach((e=>{delete l[e.id]})),l}))},e.toggleAllPageRowsSelected=t=>e.setRowSelection((n=>{const l="undefined"!==typeof t?t:!e.getIsAllPageRowsSelected(),o={...n};return e.getRowModel().rows.forEach((t=>{D(o,t.id,l,!0,e)})),o})),e.getPreSelectedRowModel=()=>e.getCoreRowModel(),e.getSelectedRowModel=a((()=>[e.getState().rowSelection,e.getCoreRowModel()]),((t,n)=>Object.keys(t).length?L(e,n):{rows:[],flatRows:[],rowsById:{}}),s(e.options,"debugTable")),e.getFilteredSelectedRowModel=a((()=>[e.getState().rowSelection,e.getFilteredRowModel()]),((t,n)=>Object.keys(t).length?L(e,n):{rows:[],flatRows:[],rowsById:{}}),s(e.options,"debugTable")),e.getGroupedSelectedRowModel=a((()=>[e.getState().rowSelection,e.getSortedRowModel()]),((t,n)=>Object.keys(t).length?L(e,n):{rows:[],flatRows:[],rowsById:{}}),s(e.options,"debugTable")),e.getIsAllRowsSelected=()=>{const t=e.getFilteredRowModel().flatRows,{rowSelection:n}=e.getState();let l=Boolean(t.length&&Object.keys(n).length);return l&&t.some((e=>e.getCanSelect()&&!n[e.id]))&&(l=!1),l},e.getIsAllPageRowsSelected=()=>{const t=e.getPaginationRowModel().flatRows.filter((e=>e.getCanSelect())),{rowSelection:n}=e.getState();let l=!!t.length;return l&&t.some((e=>!n[e.id]))&&(l=!1),l},e.getIsSomeRowsSelected=()=>{var t;const n=Object.keys(null!=(t=e.getState().rowSelection)?t:{}).length;return n>0&&n{const t=e.getPaginationRowModel().flatRows;return!e.getIsAllPageRowsSelected()&&t.filter((e=>e.getCanSelect())).some((e=>e.getIsSelected()||e.getIsSomeSelected()))},e.getToggleAllRowsSelectedHandler=()=>t=>{e.toggleAllRowsSelected(t.target.checked)},e.getToggleAllPageRowsSelectedHandler=()=>t=>{e.toggleAllPageRowsSelected(t.target.checked)}},createRow:(e,t)=>{e.toggleSelected=(n,l)=>{const o=e.getIsSelected();t.setRowSelection((r=>{var i;if(n="undefined"!==typeof n?n:!o,e.getCanSelect()&&o===n)return r;const a={...r};return D(a,e.id,n,null==(i=null==l?void 0:l.selectChildren)||i,t),a}))},e.getIsSelected=()=>{const{rowSelection:n}=t.getState();return j(e,n)},e.getIsSomeSelected=()=>{const{rowSelection:n}=t.getState();return"some"===T(e,n)},e.getIsAllSubRowsSelected=()=>{const{rowSelection:n}=t.getState();return"all"===T(e,n)},e.getCanSelect=()=>{var n;return"function"===typeof t.options.enableRowSelection?t.options.enableRowSelection(e):null==(n=t.options.enableRowSelection)||n},e.getCanSelectSubRows=()=>{var n;return"function"===typeof t.options.enableSubRowSelection?t.options.enableSubRowSelection(e):null==(n=t.options.enableSubRowSelection)||n},e.getCanMultiSelect=()=>{var n;return"function"===typeof t.options.enableMultiRowSelection?t.options.enableMultiRowSelection(e):null==(n=t.options.enableMultiRowSelection)||n},e.getToggleSelectedHandler=()=>{const t=e.getCanSelect();return n=>{var l;t&&e.toggleSelected(null==(l=n.target)?void 0:l.checked)}}}},D=(e,t,n,l,o)=>{var r;const i=o.getRow(t,!0);n?(i.getCanMultiSelect()||Object.keys(e).forEach((t=>delete e[t])),i.getCanSelect()&&(e[t]=!0)):delete e[t],l&&null!=(r=i.subRows)&&r.length&&i.getCanSelectSubRows()&&i.subRows.forEach((t=>D(e,t.id,n,l,o)))};function L(e,t){const n=e.getState().rowSelection,l=[],o={},r=function(e,t){return e.map((e=>{var t;const i=j(e,n);if(i&&(l.push(e),o[e.id]=e),null!=(t=e.subRows)&&t.length&&(e={...e,subRows:r(e.subRows)}),i)return e})).filter(Boolean)};return{rows:r(t.rows),flatRows:l,rowsById:o}}function j(e,t){var n;return null!=(n=t[e.id])&&n}function T(e,t,n){var l;if(null==(l=e.subRows)||!l.length)return!1;let o=!0,r=!1;return e.subRows.forEach((e=>{if((!r||o)&&(e.getCanSelect()&&(j(e,t)?r=!0:o=!1),e.subRows&&e.subRows.length)){const n=T(e,t);"all"===n?r=!0:"some"===n?(r=!0,o=!1):o=!1}})),o?"all":!!r&&"some"}const B=/([0-9]+)/gm;function k(e,t){return e===t?0:e>t?1:-1}function q(e){return"number"===typeof e?isNaN(e)||e===1/0||e===-1/0?"":String(e):"string"===typeof e?e:""}function $(e,t){const n=e.split(B).filter(Boolean),l=t.split(B).filter(Boolean);for(;n.length&&l.length;){const e=n.shift(),t=l.shift(),o=parseInt(e,10),r=parseInt(t,10),i=[o,r].sort();if(isNaN(i[0])){if(e>t)return 1;if(t>e)return-1}else{if(isNaN(i[1]))return isNaN(o)?-1:1;if(o>r)return 1;if(r>o)return-1}}return n.length-l.length}const U={alphanumeric:(e,t,n)=>$(q(e.getValue(n)).toLowerCase(),q(t.getValue(n)).toLowerCase()),alphanumericCaseSensitive:(e,t,n)=>$(q(e.getValue(n)),q(t.getValue(n))),text:(e,t,n)=>k(q(e.getValue(n)).toLowerCase(),q(t.getValue(n)).toLowerCase()),textCaseSensitive:(e,t,n)=>k(q(e.getValue(n)),q(t.getValue(n))),datetime:(e,t,n)=>{const l=e.getValue(n),o=t.getValue(n);return l>o?1:lk(e.getValue(n),t.getValue(n))},K=[g,{getInitialState:e=>({columnVisibility:{},...e}),getDefaultOptions:e=>({onColumnVisibilityChange:o("columnVisibility",e)}),createColumn:(e,t)=>{e.toggleVisibility=n=>{e.getCanHide()&&t.setColumnVisibility((t=>({...t,[e.id]:null!=n?n:!e.getIsVisible()})))},e.getIsVisible=()=>{var n,l;const o=e.columns;return null==(n=o.length?o.some((e=>e.getIsVisible())):null==(l=t.getState().columnVisibility)?void 0:l[e.id])||n},e.getCanHide=()=>{var n,l;return(null==(n=e.columnDef.enableHiding)||n)&&(null==(l=t.options.enableHiding)||l)},e.getToggleVisibilityHandler=()=>t=>{null==e.toggleVisibility||e.toggleVisibility(t.target.checked)}},createRow:(e,t)=>{e._getAllVisibleCells=a((()=>[e.getAllCells(),t.getState().columnVisibility]),(e=>e.filter((e=>e.column.getIsVisible()))),s(t.options,"debugRows")),e.getVisibleCells=a((()=>[e.getLeftVisibleCells(),e.getCenterVisibleCells(),e.getRightVisibleCells()]),((e,t,n)=>[...e,...t,...n]),s(t.options,"debugRows"))},createTable:e=>{const t=(t,n)=>a((()=>[n(),n().filter((e=>e.getIsVisible())).map((e=>e.id)).join("_")]),(e=>e.filter((e=>null==e.getIsVisible?void 0:e.getIsVisible()))),s(e.options,"debugColumns"));e.getVisibleFlatColumns=t(0,(()=>e.getAllFlatColumns())),e.getVisibleLeafColumns=t(0,(()=>e.getAllLeafColumns())),e.getLeftVisibleLeafColumns=t(0,(()=>e.getLeftLeafColumns())),e.getRightVisibleLeafColumns=t(0,(()=>e.getRightLeafColumns())),e.getCenterVisibleLeafColumns=t(0,(()=>e.getCenterLeafColumns())),e.setColumnVisibility=t=>null==e.options.onColumnVisibilityChange?void 0:e.options.onColumnVisibilityChange(t),e.resetColumnVisibility=t=>{var n;e.setColumnVisibility(t?{}:null!=(n=e.initialState.columnVisibility)?n:{})},e.toggleAllColumnsVisible=t=>{var n;t=null!=(n=t)?n:!e.getIsAllColumnsVisible(),e.setColumnVisibility(e.getAllLeafColumns().reduce(((e,n)=>({...e,[n.id]:t||!(null!=n.getCanHide&&n.getCanHide())})),{}))},e.getIsAllColumnsVisible=()=>!e.getAllLeafColumns().some((e=>!(null!=e.getIsVisible&&e.getIsVisible()))),e.getIsSomeColumnsVisible=()=>e.getAllLeafColumns().some((e=>null==e.getIsVisible?void 0:e.getIsVisible())),e.getToggleAllColumnsVisibilityHandler=()=>t=>{var n;e.toggleAllColumnsVisible(null==(n=t.target)?void 0:n.checked)}}},V,O,m,M,{createTable:e=>{e._getGlobalFacetedRowModel=e.options.getFacetedRowModel&&e.options.getFacetedRowModel(e,"__global__"),e.getGlobalFacetedRowModel=()=>e.options.manualFiltering||!e._getGlobalFacetedRowModel?e.getPreFilteredRowModel():e._getGlobalFacetedRowModel(),e._getGlobalFacetedUniqueValues=e.options.getFacetedUniqueValues&&e.options.getFacetedUniqueValues(e,"__global__"),e.getGlobalFacetedUniqueValues=()=>e._getGlobalFacetedUniqueValues?e._getGlobalFacetedUniqueValues():new Map,e._getGlobalFacetedMinMaxValues=e.options.getFacetedMinMaxValues&&e.options.getFacetedMinMaxValues(e,"__global__"),e.getGlobalFacetedMinMaxValues=()=>{if(e._getGlobalFacetedMinMaxValues)return e._getGlobalFacetedMinMaxValues()}}},{getInitialState:e=>({globalFilter:void 0,...e}),getDefaultOptions:e=>({onGlobalFilterChange:o("globalFilter",e),globalFilterFn:"auto",getColumnCanGlobalFilter:t=>{var n;const l=null==(n=e.getCoreRowModel().flatRows[0])||null==(n=n._getAllCellsByColumnId()[t.id])?void 0:n.getValue();return"string"===typeof l||"number"===typeof l}}),createColumn:(e,t)=>{e.getCanGlobalFilter=()=>{var n,l,o,r;return(null==(n=e.columnDef.enableGlobalFilter)||n)&&(null==(l=t.options.enableGlobalFilter)||l)&&(null==(o=t.options.enableFilters)||o)&&(null==(r=null==t.options.getColumnCanGlobalFilter?void 0:t.options.getColumnCanGlobalFilter(e))||r)&&!!e.accessorFn}},createTable:e=>{e.getGlobalAutoFilterFn=()=>I.includesString,e.getGlobalFilterFn=()=>{var t,n;const{globalFilterFn:l}=e.options;return r(l)?l:"auto"===l?e.getGlobalAutoFilterFn():null!=(t=null==(n=e.options.filterFns)?void 0:n[l])?t:I[l]},e.setGlobalFilter=t=>{null==e.options.onGlobalFilterChange||e.options.onGlobalFilterChange(t)},e.resetGlobalFilter=t=>{e.setGlobalFilter(t?void 0:e.initialState.globalFilter)}}},{getInitialState:e=>({sorting:[],...e}),getDefaultColumnDef:()=>({sortingFn:"auto",sortUndefined:1}),getDefaultOptions:e=>({onSortingChange:o("sorting",e),isMultiSortEvent:e=>e.shiftKey}),createColumn:(e,t)=>{e.getAutoSortingFn=()=>{const n=t.getFilteredRowModel().flatRows.slice(10);let l=!1;for(const t of n){const n=null==t?void 0:t.getValue(e.id);if("[object Date]"===Object.prototype.toString.call(n))return U.datetime;if("string"===typeof n&&(l=!0,n.split(B).length>1))return U.alphanumeric}return l?U.text:U.basic},e.getAutoSortDir=()=>{const n=t.getFilteredRowModel().flatRows[0];return"string"===typeof(null==n?void 0:n.getValue(e.id))?"asc":"desc"},e.getSortingFn=()=>{var n,l;if(!e)throw new Error;return r(e.columnDef.sortingFn)?e.columnDef.sortingFn:"auto"===e.columnDef.sortingFn?e.getAutoSortingFn():null!=(n=null==(l=t.options.sortingFns)?void 0:l[e.columnDef.sortingFn])?n:U[e.columnDef.sortingFn]},e.toggleSorting=(n,l)=>{const o=e.getNextSortingOrder(),r="undefined"!==typeof n&&null!==n;t.setSorting((i=>{const a=null==i?void 0:i.find((t=>t.id===e.id)),s=null==i?void 0:i.findIndex((t=>t.id===e.id));let u,d=[],g=r?n:"desc"===o;var c;(u=null!=i&&i.length&&e.getCanMultiSort()&&l?a?"toggle":"add":null!=i&&i.length&&s!==i.length-1?"replace":a?"toggle":"replace","toggle"===u&&(r||o||(u="remove")),"add"===u)?(d=[...i,{id:e.id,desc:g}],d.splice(0,d.length-(null!=(c=t.options.maxMultiSortColCount)?c:Number.MAX_SAFE_INTEGER))):d="toggle"===u?i.map((t=>t.id===e.id?{...t,desc:g}:t)):"remove"===u?i.filter((t=>t.id!==e.id)):[{id:e.id,desc:g}];return d}))},e.getFirstSortDir=()=>{var n,l;return(null!=(n=null!=(l=e.columnDef.sortDescFirst)?l:t.options.sortDescFirst)?n:"desc"===e.getAutoSortDir())?"desc":"asc"},e.getNextSortingOrder=n=>{var l,o;const r=e.getFirstSortDir(),i=e.getIsSorted();return i?!!(i===r||null!=(l=t.options.enableSortingRemoval)&&!l||n&&null!=(o=t.options.enableMultiRemove)&&!o)&&("desc"===i?"asc":"desc"):r},e.getCanSort=()=>{var n,l;return(null==(n=e.columnDef.enableSorting)||n)&&(null==(l=t.options.enableSorting)||l)&&!!e.accessorFn},e.getCanMultiSort=()=>{var n,l;return null!=(n=null!=(l=e.columnDef.enableMultiSort)?l:t.options.enableMultiSort)?n:!!e.accessorFn},e.getIsSorted=()=>{var n;const l=null==(n=t.getState().sorting)?void 0:n.find((t=>t.id===e.id));return!!l&&(l.desc?"desc":"asc")},e.getSortIndex=()=>{var n,l;return null!=(n=null==(l=t.getState().sorting)?void 0:l.findIndex((t=>t.id===e.id)))?n:-1},e.clearSorting=()=>{t.setSorting((t=>null!=t&&t.length?t.filter((t=>t.id!==e.id)):[]))},e.getToggleSortingHandler=()=>{const n=e.getCanSort();return l=>{n&&(null==l.persist||l.persist(),null==e.toggleSorting||e.toggleSorting(void 0,!!e.getCanMultiSort()&&(null==t.options.isMultiSortEvent?void 0:t.options.isMultiSortEvent(l))))}}},createTable:e=>{e.setSorting=t=>null==e.options.onSortingChange?void 0:e.options.onSortingChange(t),e.resetSorting=t=>{var n,l;e.setSorting(t?[]:null!=(n=null==(l=e.initialState)?void 0:l.sorting)?n:[])},e.getPreSortedRowModel=()=>e.getGroupedRowModel(),e.getSortedRowModel=()=>(!e._getSortedRowModel&&e.options.getSortedRowModel&&(e._getSortedRowModel=e.options.getSortedRowModel(e)),e.options.manualSorting||!e._getSortedRowModel?e.getPreSortedRowModel():e._getSortedRowModel())}},E,{getInitialState:e=>({expanded:{},...e}),getDefaultOptions:e=>({onExpandedChange:o("expanded",e),paginateExpandedRows:!0}),createTable:e=>{let t=!1,n=!1;e._autoResetExpanded=()=>{var l,o;if(t){if(null!=(l=null!=(o=e.options.autoResetAll)?o:e.options.autoResetExpanded)?l:!e.options.manualExpanding){if(n)return;n=!0,e._queue((()=>{e.resetExpanded(),n=!1}))}}else e._queue((()=>{t=!0}))},e.setExpanded=t=>null==e.options.onExpandedChange?void 0:e.options.onExpandedChange(t),e.toggleAllRowsExpanded=t=>{(null!=t?t:!e.getIsAllRowsExpanded())?e.setExpanded(!0):e.setExpanded({})},e.resetExpanded=t=>{var n,l;e.setExpanded(t?{}:null!=(n=null==(l=e.initialState)?void 0:l.expanded)?n:{})},e.getCanSomeRowsExpand=()=>e.getPrePaginationRowModel().flatRows.some((e=>e.getCanExpand())),e.getToggleAllRowsExpandedHandler=()=>t=>{null==t.persist||t.persist(),e.toggleAllRowsExpanded()},e.getIsSomeRowsExpanded=()=>{const t=e.getState().expanded;return!0===t||Object.values(t).some(Boolean)},e.getIsAllRowsExpanded=()=>{const t=e.getState().expanded;return"boolean"===typeof t?!0===t:!!Object.keys(t).length&&!e.getRowModel().flatRows.some((e=>!e.getIsExpanded()))},e.getExpandedDepth=()=>{let t=0;return(!0===e.getState().expanded?Object.keys(e.getRowModel().rowsById):Object.keys(e.getState().expanded)).forEach((e=>{const n=e.split(".");t=Math.max(t,n.length)})),t},e.getPreExpandedRowModel=()=>e.getSortedRowModel(),e.getExpandedRowModel=()=>(!e._getExpandedRowModel&&e.options.getExpandedRowModel&&(e._getExpandedRowModel=e.options.getExpandedRowModel(e)),e.options.manualExpanding||!e._getExpandedRowModel?e.getPreExpandedRowModel():e._getExpandedRowModel())},createRow:(e,t)=>{e.toggleExpanded=n=>{t.setExpanded((l=>{var o;const r=!0===l||!(null==l||!l[e.id]);let i={};if(!0===l?Object.keys(t.getRowModel().rowsById).forEach((e=>{i[e]=!0})):i=l,n=null!=(o=n)?o:!r,!r&&n)return{...i,[e.id]:!0};if(r&&!n){const{[e.id]:t,...n}=i;return n}return l}))},e.getIsExpanded=()=>{var n;const l=t.getState().expanded;return!!(null!=(n=null==t.options.getIsRowExpanded?void 0:t.options.getIsRowExpanded(e))?n:!0===l||(null==l?void 0:l[e.id]))},e.getCanExpand=()=>{var n,l,o;return null!=(n=null==t.options.getRowCanExpand?void 0:t.options.getRowCanExpand(e))?n:(null==(l=t.options.enableExpanding)||l)&&!(null==(o=e.subRows)||!o.length)},e.getIsAllParentsExpanded=()=>{let n=!0,l=e;for(;n&&l.parentId;)l=t.getRow(l.parentId,!0),n=l.getIsExpanded();return n},e.getToggleExpandedHandler=()=>{const t=e.getCanExpand();return()=>{t&&e.toggleExpanded()}}}},{getInitialState:e=>({...e,pagination:{pageIndex:0,pageSize:10,...null==e?void 0:e.pagination}}),getDefaultOptions:e=>({onPaginationChange:o("pagination",e)}),createTable:e=>{let t=!1,n=!1;e._autoResetPageIndex=()=>{var l,o;if(t){if(null!=(l=null!=(o=e.options.autoResetAll)?o:e.options.autoResetPageIndex)?l:!e.options.manualPagination){if(n)return;n=!0,e._queue((()=>{e.resetPageIndex(),n=!1}))}}else e._queue((()=>{t=!0}))},e.setPagination=t=>null==e.options.onPaginationChange?void 0:e.options.onPaginationChange((e=>l(t,e))),e.resetPagination=t=>{var n;e.setPagination(t?{pageIndex:0,pageSize:10}:null!=(n=e.initialState.pagination)?n:{pageIndex:0,pageSize:10})},e.setPageIndex=t=>{e.setPagination((n=>{let o=l(t,n.pageIndex);const r="undefined"===typeof e.options.pageCount||-1===e.options.pageCount?Number.MAX_SAFE_INTEGER:e.options.pageCount-1;return o=Math.max(0,Math.min(o,r)),{...n,pageIndex:o}}))},e.resetPageIndex=t=>{var n,l;e.setPageIndex(t?0:null!=(n=null==(l=e.initialState)||null==(l=l.pagination)?void 0:l.pageIndex)?n:0)},e.resetPageSize=t=>{var n,l;e.setPageSize(t?10:null!=(n=null==(l=e.initialState)||null==(l=l.pagination)?void 0:l.pageSize)?n:10)},e.setPageSize=t=>{e.setPagination((e=>{const n=Math.max(1,l(t,e.pageSize)),o=e.pageSize*e.pageIndex,r=Math.floor(o/n);return{...e,pageIndex:r,pageSize:n}}))},e.setPageCount=t=>e.setPagination((n=>{var o;let r=l(t,null!=(o=e.options.pageCount)?o:-1);return"number"===typeof r&&(r=Math.max(-1,r)),{...n,pageCount:r}})),e.getPageOptions=a((()=>[e.getPageCount()]),(e=>{let t=[];return e&&e>0&&(t=[...new Array(e)].fill(null).map(((e,t)=>t))),t}),s(e.options,"debugTable")),e.getCanPreviousPage=()=>e.getState().pagination.pageIndex>0,e.getCanNextPage=()=>{const{pageIndex:t}=e.getState().pagination,n=e.getPageCount();return-1===n||0!==n&&te.setPageIndex((e=>e-1)),e.nextPage=()=>e.setPageIndex((e=>e+1)),e.firstPage=()=>e.setPageIndex(0),e.lastPage=()=>e.setPageIndex(e.getPageCount()-1),e.getPrePaginationRowModel=()=>e.getExpandedRowModel(),e.getPaginationRowModel=()=>(!e._getPaginationRowModel&&e.options.getPaginationRowModel&&(e._getPaginationRowModel=e.options.getPaginationRowModel(e)),e.options.manualPagination||!e._getPaginationRowModel?e.getPrePaginationRowModel():e._getPaginationRowModel()),e.getPageCount=()=>{var t;return null!=(t=e.options.pageCount)?t:Math.ceil(e.getRowCount()/e.getState().pagination.pageSize)},e.getRowCount=()=>{var t;return null!=(t=e.options.rowCount)?t:e.getPrePaginationRowModel().rows.length}}},{getInitialState:e=>({rowPinning:{top:[],bottom:[]},...e}),getDefaultOptions:e=>({onRowPinningChange:o("rowPinning",e)}),createRow:(e,t)=>{e.pin=(n,l,o)=>{const r=l?e.getLeafRows().map((e=>{let{id:t}=e;return t})):[],i=o?e.getParentRows().map((e=>{let{id:t}=e;return t})):[],a=new Set([...i,e.id,...r]);t.setRowPinning((e=>{var t,l,o,r,i,s;return"bottom"===n?{top:(null!=(o=null==e?void 0:e.top)?o:[]).filter((e=>!(null!=a&&a.has(e)))),bottom:[...(null!=(r=null==e?void 0:e.bottom)?r:[]).filter((e=>!(null!=a&&a.has(e)))),...Array.from(a)]}:"top"===n?{top:[...(null!=(i=null==e?void 0:e.top)?i:[]).filter((e=>!(null!=a&&a.has(e)))),...Array.from(a)],bottom:(null!=(s=null==e?void 0:e.bottom)?s:[]).filter((e=>!(null!=a&&a.has(e))))}:{top:(null!=(t=null==e?void 0:e.top)?t:[]).filter((e=>!(null!=a&&a.has(e)))),bottom:(null!=(l=null==e?void 0:e.bottom)?l:[]).filter((e=>!(null!=a&&a.has(e))))}}))},e.getCanPin=()=>{var n;const{enableRowPinning:l,enablePinning:o}=t.options;return"function"===typeof l?l(e):null==(n=null!=l?l:o)||n},e.getIsPinned=()=>{const n=[e.id],{top:l,bottom:o}=t.getState().rowPinning,r=n.some((e=>null==l?void 0:l.includes(e))),i=n.some((e=>null==o?void 0:o.includes(e)));return r?"top":!!i&&"bottom"},e.getPinnedIndex=()=>{var n,l;const o=e.getIsPinned();if(!o)return-1;const r=null==(n="top"===o?t.getTopRows():t.getBottomRows())?void 0:n.map((e=>{let{id:t}=e;return t}));return null!=(l=null==r?void 0:r.indexOf(e.id))?l:-1}},createTable:e=>{e.setRowPinning=t=>null==e.options.onRowPinningChange?void 0:e.options.onRowPinningChange(t),e.resetRowPinning=t=>{var n,l;return e.setRowPinning(t?{top:[],bottom:[]}:null!=(n=null==(l=e.initialState)?void 0:l.rowPinning)?n:{top:[],bottom:[]})},e.getIsSomeRowsPinned=t=>{var n;const l=e.getState().rowPinning;var o,r;return t?Boolean(null==(n=l[t])?void 0:n.length):Boolean((null==(o=l.top)?void 0:o.length)||(null==(r=l.bottom)?void 0:r.length))},e._getPinnedRows=(t,n,l)=>{var o;return(null==(o=e.options.keepPinnedRows)||o?(null!=n?n:[]).map((t=>{const n=e.getRow(t,!0);return n.getIsAllParentsExpanded()?n:null})):(null!=n?n:[]).map((e=>t.find((t=>t.id===e))))).filter(Boolean).map((e=>({...e,position:l})))},e.getTopRows=a((()=>[e.getRowModel().rows,e.getState().rowPinning.top]),((t,n)=>e._getPinnedRows(t,n,"top")),s(e.options,"debugRows")),e.getBottomRows=a((()=>[e.getRowModel().rows,e.getState().rowPinning.bottom]),((t,n)=>e._getPinnedRows(t,n,"bottom")),s(e.options,"debugRows")),e.getCenterRows=a((()=>[e.getRowModel().rows,e.getState().rowPinning.top,e.getState().rowPinning.bottom]),((e,t,n)=>{const l=new Set([...null!=t?t:[],...null!=n?n:[]]);return e.filter((e=>!l.has(e.id)))}),s(e.options,"debugRows"))}},A,z];function X(e){var t,n;const o=[...K,...null!=(t=e._features)?t:[]];let r={_features:o};const i=r._features.reduce(((e,t)=>Object.assign(e,null==t.getDefaultOptions?void 0:t.getDefaultOptions(r))),{});let u={...null!=(n=e.initialState)?n:{}};r._features.forEach((e=>{var t;u=null!=(t=null==e.getInitialState?void 0:e.getInitialState(u))?t:u}));const d=[];let g=!1;const c={_features:o,options:{...i,...e},initialState:u,_queue:e=>{d.push(e),g||(g=!0,Promise.resolve().then((()=>{for(;d.length;)d.shift()();g=!1})).catch((e=>setTimeout((()=>{throw e})))))},reset:()=>{r.setState(r.initialState)},setOptions:e=>{const t=l(e,r.options);r.options=(e=>r.options.mergeOptions?r.options.mergeOptions(i,e):{...i,...e})(t)},getState:()=>r.options.state,setState:e=>{null==r.options.onStateChange||r.options.onStateChange(e)},_getRowId:(e,t,n)=>{var l;return null!=(l=null==r.options.getRowId?void 0:r.options.getRowId(e,t,n))?l:`${n?[n.id,t].join("."):t}`},getCoreRowModel:()=>(r._getCoreRowModel||(r._getCoreRowModel=r.options.getCoreRowModel(r)),r._getCoreRowModel()),getRowModel:()=>r.getPaginationRowModel(),getRow:(e,t)=>{let n=(t?r.getPrePaginationRowModel():r.getRowModel()).rowsById[e];if(!n&&(n=r.getCoreRowModel().rowsById[e],!n))throw new Error;return n},_getDefaultColumnDef:a((()=>[r.options.defaultColumn]),(e=>{var t;return e=null!=(t=e)?t:{},{header:e=>{const t=e.header.column.columnDef;return t.accessorKey?t.accessorKey:t.accessorFn?t.id:null},cell:e=>{var t,n;return null!=(t=null==(n=e.renderValue())||null==n.toString?void 0:n.toString())?t:null},...r._features.reduce(((e,t)=>Object.assign(e,null==t.getDefaultColumnDef?void 0:t.getDefaultColumnDef())),{}),...e}}),s(e,"debugColumns")),_getColumnDefs:()=>r.options.columns,getAllColumns:a((()=>[r._getColumnDefs()]),(e=>{const t=function(e,n,l){return void 0===l&&(l=0),e.map((e=>{const o=function(e,t,n,l){var o,r;const i={...e._getDefaultColumnDef(),...t},u=i.accessorKey;let d,g=null!=(o=null!=(r=i.id)?r:u?"function"===typeof String.prototype.replaceAll?u.replaceAll(".","_"):u.replace(/\./g,"_"):void 0)?o:"string"===typeof i.header?i.header:void 0;if(i.accessorFn?d=i.accessorFn:u&&(d=u.includes(".")?e=>{let t=e;for(const l of u.split(".")){var n;t=null==(n=t)?void 0:n[l]}return t}:e=>e[i.accessorKey]),!g)throw new Error;let c={id:`${String(g)}`,accessorFn:d,parent:l,depth:n,columnDef:i,columns:[],getFlatColumns:a((()=>[!0]),(()=>{var e;return[c,...null==(e=c.columns)?void 0:e.flatMap((e=>e.getFlatColumns()))]}),s(e.options,"debugColumns")),getLeafColumns:a((()=>[e._getOrderColumnsFn()]),(e=>{var t;if(null!=(t=c.columns)&&t.length){let t=c.columns.flatMap((e=>e.getLeafColumns()));return e(t)}return[c]}),s(e.options,"debugColumns"))};for(const a of e._features)null==a.createColumn||a.createColumn(c,e);return c}(r,e,l,n),i=e;return o.columns=i.columns?t(i.columns,o,l+1):[],o}))};return t(e)}),s(e,"debugColumns")),getAllFlatColumns:a((()=>[r.getAllColumns()]),(e=>e.flatMap((e=>e.getFlatColumns()))),s(e,"debugColumns")),_getAllFlatColumnsById:a((()=>[r.getAllFlatColumns()]),(e=>e.reduce(((e,t)=>(e[t.id]=t,e)),{})),s(e,"debugColumns")),getAllLeafColumns:a((()=>[r.getAllColumns(),r._getOrderColumnsFn()]),((e,t)=>t(e.flatMap((e=>e.getLeafColumns())))),s(e,"debugColumns")),getColumn:e=>r._getAllFlatColumnsById()[e]};Object.assign(r,c);for(let l=0;la((()=>[e.options.data]),(t=>{const n={rows:[],flatRows:[],rowsById:{}},l=function(t,o,r){void 0===o&&(o=0);const i=[];for(let s=0;se._autoResetPageIndex())))}function W(){return e=>a((()=>[e.getState().expanded,e.getPreExpandedRowModel(),e.options.paginateExpandedRows]),((e,t,n)=>!t.rows.length||!0!==e&&!Object.keys(null!=e?e:{}).length?t:n?J(t):t),s(e.options,"debugTable"))}function J(e){const t=[],n=e=>{var l;t.push(e),null!=(l=e.subRows)&&l.length&&e.getIsExpanded()&&e.subRows.forEach(n)};return e.rows.forEach(n),{rows:t,flatRows:e.flatRows,rowsById:e.rowsById}}function Q(){return e=>a((()=>[e.getState().grouping,e.getPreGroupedRowModel()]),((t,n)=>{if(!n.rows.length||!t.length)return n.rows.forEach((e=>{e.depth=0,e.parentId=void 0})),n;const l=t.filter((t=>e.getColumn(t))),o=[],r={},a=function(t,n,s){if(void 0===n&&(n=0),n>=l.length)return t.map((e=>(e.depth=n,o.push(e),r[e.id]=e,e.subRows&&(e.subRows=a(e.subRows,n+1,e.id)),e)));const u=l[n],d=function(e,t){const n=new Map;return e.reduce(((e,n)=>{const l=`${n.getGroupingValue(t)}`,o=e.get(l);return o?o.push(n):e.set(l,[n]),e}),n)}(t,u),g=Array.from(d.entries()).map(((t,d)=>{let[g,c]=t,m=`${u}:${g}`;m=s?`${s}>${m}`:m;const f=a(c,n+1,m);f.forEach((e=>{e.parentId=m}));const v=n?i(c,(e=>e.subRows)):c,w=p(e,m,v[0].original,d,n,void 0,s);return Object.assign(w,{groupingColumnId:u,groupingValue:g,subRows:f,leafRows:v,getValue:t=>{if(l.includes(t)){if(w._valuesCache.hasOwnProperty(t))return w._valuesCache[t];var n;if(c[0])w._valuesCache[t]=null!=(n=c[0].getValue(t))?n:void 0;return w._valuesCache[t]}if(w._groupingValuesCache.hasOwnProperty(t))return w._groupingValuesCache[t];const o=e.getColumn(t),r=null==o?void 0:o.getAggregationFn();return r?(w._groupingValuesCache[t]=r(t,v,c),w._groupingValuesCache[t]):void 0}}),f.forEach((e=>{o.push(e),r[e.id]=e})),w}));return g},s=a(n.rows,0);return s.forEach((e=>{o.push(e),r[e.id]=e})),{rows:s,flatRows:o,rowsById:r}}),s(e.options,"debugTable",0,(()=>{e._queue((()=>{e._autoResetExpanded(),e._autoResetPageIndex()}))})))}function Y(){return e=>a((()=>[e.getState().sorting,e.getPreSortedRowModel()]),((t,n)=>{if(!n.rows.length||null==t||!t.length)return n;const l=e.getState().sorting,o=[],r=l.filter((t=>{var n;return null==(n=e.getColumn(t.id))?void 0:n.getCanSort()})),i={};r.forEach((t=>{const n=e.getColumn(t.id);n&&(i[t.id]={sortUndefined:n.columnDef.sortUndefined,invertSorting:n.columnDef.invertSorting,sortingFn:n.getSortingFn()})}));const a=e=>{const t=e.map((e=>({...e})));return t.sort(((e,t)=>{for(let l=0;l{var t;o.push(e),null!=(t=e.subRows)&&t.length&&(e.subRows=a(e.subRows))})),t};return{rows:a(n.rows),flatRows:o,rowsById:n.rowsById}}),s(e.options,"debugTable",0,(()=>e._autoResetPageIndex())))}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/73442.0bbc74fd.chunk.js b/ydb/core/viewer/monitoring/static/js/73442.0bbc74fd.chunk.js new file mode 100644 index 000000000000..0b2b93398729 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/73442.0bbc74fd.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[73442],{73442:(e,t,i)=>{i.d(t,{default:()=>n});var s=i(91713);const n=i.n(s)()},91713:e=>{function t(e){e.languages.mizar={comment:/::.+/,keyword:/@proof\b|\b(?:according|aggregate|all|and|antonym|are|as|associativity|assume|asymmetry|attr|be|begin|being|by|canceled|case|cases|clusters?|coherence|commutativity|compatibility|connectedness|consider|consistency|constructors|contradiction|correctness|def|deffunc|define|definitions?|defpred|do|does|end|environ|equals|ex|exactly|existence|for|from|func|given|hence|hereby|holds|idempotence|identity|iff?|implies|involutiveness|irreflexivity|is|it|let|means|mode|non|not|notations?|now|of|or|otherwise|over|per|pred|prefix|projectivity|proof|provided|qua|reconsider|redefine|reduce|reducibility|reflexivity|registrations?|requirements|reserve|sch|schemes?|section|selector|set|sethood|st|struct|such|suppose|symmetry|synonym|take|that|the|then|theorems?|thesis|thus|to|transitivity|uniqueness|vocabular(?:ies|y)|when|where|with|wrt)\b/,parameter:{pattern:/\$(?:10|\d)/,alias:"variable"},variable:/\b\w+(?=:)/,number:/(?:\b|-)\d+\b/,operator:/\.\.\.|->|&|\.?=/,punctuation:/\(#|#\)|[,:;\[\](){}]/}}e.exports=t,t.displayName="mizar",t.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/73478.353da8fe.chunk.js b/ydb/core/viewer/monitoring/static/js/73478.353da8fe.chunk.js new file mode 100644 index 000000000000..c77da81f9549 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/73478.353da8fe.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 73478.353da8fe.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[73478],{73478:(e,t,s)=>{s.r(t),s.d(t,{conf:()=>n,language:()=>o});var n={comments:{blockComment:["\x3c!--","--\x3e"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">",notIn:["string"]}],surroundingPairs:[{open:"(",close:")"},{open:"[",close:"]"},{open:"`",close:"`"}],folding:{markers:{start:new RegExp("^\\s*\x3c!--\\s*#?region\\b.*--\x3e"),end:new RegExp("^\\s*\x3c!--\\s*#?endregion\\b.*--\x3e")}}},o={defaultToken:"",tokenPostfix:".md",control:/[\\`*_\[\]{}()#+\-\.!]/,noncontrol:/[^\\`*_\[\]{}()#+\-\.!]/,escapes:/\\(?:@control)/,jsescapes:/\\(?:[btnfr\\"']|[0-7][0-7]?|[0-3][0-7]{2})/,empty:["area","base","basefont","br","col","frame","hr","img","input","isindex","link","meta","param"],tokenizer:{root:[[/^\s*\|/,"@rematch","@table_header"],[/^(\s{0,3})(#+)((?:[^\\#]|@escapes)+)((?:#+)?)/,["white","keyword","keyword","keyword"]],[/^\s*(=+|\-+)\s*$/,"keyword"],[/^\s*((\*[ ]?)+)\s*$/,"meta.separator"],[/^\s*>+/,"comment"],[/^\s*([\*\-+:]|\d+\.)\s/,"keyword"],[/^(\t|[ ]{4})[^ ].*$/,"string"],[/^\s*~~~\s*((?:\w|[\/\-#])+)?\s*$/,{token:"string",next:"@codeblock"}],[/^\s*```\s*((?:\w|[\/\-#])+).*$/,{token:"string",next:"@codeblockgh",nextEmbedded:"$1"}],[/^\s*```\s*$/,{token:"string",next:"@codeblock"}],{include:"@linecontent"}],table_header:[{include:"@table_common"},[/[^\|]+/,"keyword.table.header"]],table_body:[{include:"@table_common"},{include:"@linecontent"}],table_common:[[/\s*[\-:]+\s*/,{token:"keyword",switchTo:"table_body"}],[/^\s*\|/,"keyword.table.left"],[/^\s*[^\|]/,"@rematch","@pop"],[/^\s*$/,"@rematch","@pop"],[/\|/,{cases:{"@eos":"keyword.table.right","@default":"keyword.table.middle"}}]],codeblock:[[/^\s*~~~\s*$/,{token:"string",next:"@pop"}],[/^\s*```\s*$/,{token:"string",next:"@pop"}],[/.*$/,"variable.source"]],codeblockgh:[[/```\s*$/,{token:"string",next:"@pop",nextEmbedded:"@pop"}],[/[^`]+/,"variable.source"]],linecontent:[[/&\w+;/,"string.escape"],[/@escapes/,"escape"],[/\b__([^\\_]|@escapes|_(?!_))+__\b/,"strong"],[/\*\*([^\\*]|@escapes|\*(?!\*))+\*\*/,"strong"],[/\b_[^_]+_\b/,"emphasis"],[/\*([^\\*]|@escapes)+\*/,"emphasis"],[/`([^\\`]|@escapes)+`/,"variable"],[/\{+[^}]+\}+/,"string.target"],[/(!?\[)((?:[^\]\\]|@escapes)*)(\]\([^\)]+\))/,["string.link","","string.link"]],[/(!?\[)((?:[^\]\\]|@escapes)*)(\])/,"string.link"],{include:"html"}],html:[[/<(\w+)\/>/,"tag"],[/<(\w+)(\-|\w)*/,{cases:{"@empty":{token:"tag",next:"@tag.$1"},"@default":{token:"tag",next:"@tag.$1"}}}],[/<\/(\w+)(\-|\w)*\s*>/,{token:"tag"}],[//,"comment","@pop"],[//,{token:"comment",next:"@pop"}],[//,{token:"comment",next:"@pop"}],[//,"comment.html","@pop"],[/[^-]+/,"comment.content.html"],[/./,"comment.content.html"]],otherTag:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.otherTag"}],[/\/?>/,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.script"}],[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],scriptAfterType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.scriptAfterType"}],[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.scriptAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.scriptWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInEmbeddedState.scriptEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],style:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.style"}],[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],styleAfterType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.styleAfterType"}],[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.styleAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInSimpleState.styleWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/<\?((php)|=)?/,{token:"@rematch",switchTo:"@phpInEmbeddedState.styleEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],phpInSimpleState:[[/<\?((php)|=)?/,"metatag.php"],[/\?>/,{token:"metatag.php",switchTo:"@$S2.$S3"}],{include:"phpRoot"}],phpInEmbeddedState:[[/<\?((php)|=)?/,"metatag.php"],[/\?>/,{token:"metatag.php",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}],{include:"phpRoot"}],phpRoot:[[/[a-zA-Z_]\w*/,{cases:{"@phpKeywords":{token:"keyword.php"},"@phpCompileTimeConstants":{token:"constant.php"},"@default":"identifier.php"}}],[/[$a-zA-Z_]\w*/,{cases:{"@phpPreDefinedVariables":{token:"variable.predefined.php"},"@default":"variable.php"}}],[/[{}]/,"delimiter.bracket.php"],[/[\[\]]/,"delimiter.array.php"],[/[()]/,"delimiter.parenthesis.php"],[/[ \t\r\n]+/],[/(#|\/\/)$/,"comment.php"],[/(#|\/\/)/,"comment.php","@phpLineComment"],[/\/\*/,"comment.php","@phpComment"],[/"/,"string.php","@phpDoubleQuoteString"],[/'/,"string.php","@phpSingleQuoteString"],[/[\+\-\*\%\&\|\^\~\!\=\<\>\/\?\;\:\.\,\@]/,"delimiter.php"],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float.php"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float.php"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F]/,"number.hex.php"],[/0[0-7']*[0-7]/,"number.octal.php"],[/0[bB][0-1']*[0-1]/,"number.binary.php"],[/\d[\d']*/,"number.php"],[/\d/,"number.php"]],phpComment:[[/\*\//,"comment.php","@pop"],[/[^*]+/,"comment.php"],[/./,"comment.php"]],phpLineComment:[[/\?>/,{token:"@rematch",next:"@pop"}],[/.$/,"comment.php","@pop"],[/[^?]+$/,"comment.php","@pop"],[/[^?]+/,"comment.php"],[/./,"comment.php"]],phpDoubleQuoteString:[[/[^\\"]+/,"string.php"],[/@escapes/,"string.escape.php"],[/\\./,"string.escape.invalid.php"],[/"/,"string.php","@pop"]],phpSingleQuoteString:[[/[^\\']+/,"string.php"],[/@escapes/,"string.escape.php"],[/\\./,"string.escape.invalid.php"],[/'/,"string.php","@pop"]]},phpKeywords:["abstract","and","array","as","break","callable","case","catch","cfunction","class","clone","const","continue","declare","default","do","else","elseif","enddeclare","endfor","endforeach","endif","endswitch","endwhile","extends","false","final","for","foreach","function","global","goto","if","implements","interface","instanceof","insteadof","namespace","new","null","object","old_function","or","private","protected","public","resource","static","switch","throw","trait","try","true","use","var","while","xor","die","echo","empty","exit","eval","include","include_once","isset","list","require","require_once","return","print","unset","yield","__construct"],phpCompileTimeConstants:["__CLASS__","__DIR__","__FILE__","__LINE__","__NAMESPACE__","__METHOD__","__FUNCTION__","__TRAIT__"],phpPreDefinedVariables:["$GLOBALS","$_SERVER","$_GET","$_POST","$_FILES","$_REQUEST","$_SESSION","$_ENV","$_COOKIE","$php_errormsg","$HTTP_RAW_POST_DATA","$http_response_header","$argc","$argv"],escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9010.4bfaf5fa.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/86342.528e5efc.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/9010.4bfaf5fa.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/86342.528e5efc.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/86472.57a5a1cc.chunk.js b/ydb/core/viewer/monitoring/static/js/86472.57a5a1cc.chunk.js new file mode 100644 index 000000000000..62e4c3cca9da --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/86472.57a5a1cc.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[86472],{69051:e=>{function a(e){e.languages.smalltalk={comment:{pattern:/"(?:""|[^"])*"/,greedy:!0},char:{pattern:/\$./,greedy:!0},string:{pattern:/'(?:''|[^'])*'/,greedy:!0},symbol:/#[\da-z]+|#(?:-|([+\/\\*~<>=@%|&?!])\1?)|#(?=\()/i,"block-arguments":{pattern:/(\[\s*):[^\[|]*\|/,lookbehind:!0,inside:{variable:/:[\da-z]+/i,punctuation:/\|/}},"temporary-variables":{pattern:/\|[^|]+\|/,inside:{variable:/[\da-z]+/i,punctuation:/\|/}},keyword:/\b(?:new|nil|self|super)\b/,boolean:/\b(?:false|true)\b/,number:[/\d+r-?[\dA-Z]+(?:\.[\dA-Z]+)?(?:e-?\d+)?/,/\b\d+(?:\.\d+)?(?:e-?\d+)?/],operator:/[<=]=?|:=|~[~=]|\/\/?|\\\\|>[>=]?|[!^+\-*&|,@]/,punctuation:/[.;:?\[\](){}]/}}e.exports=a,a.displayName="smalltalk",a.aliases=[]},86472:(e,a,t)=>{t.d(a,{default:()=>n});var d=t(69051);const n=t.n(d)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/86658.6a6caa74.chunk.js b/ydb/core/viewer/monitoring/static/js/86658.6a6caa74.chunk.js new file mode 100644 index 000000000000..2d4cb3d9615f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/86658.6a6caa74.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 86658.6a6caa74.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[86658],{86658:(e,o,r)=>{r.r(o),r.d(o,{conf:()=>t,language:()=>a});var t={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'}]},a={defaultToken:"",tokenPostfix:".r",roxygen:["@alias","@aliases","@assignee","@author","@backref","@callGraph","@callGraphDepth","@callGraphPrimitives","@concept","@describeIn","@description","@details","@docType","@encoding","@evalNamespace","@evalRd","@example","@examples","@export","@exportClass","@exportMethod","@exportPattern","@family","@field","@formals","@format","@import","@importClassesFrom","@importFrom","@importMethodsFrom","@include","@inherit","@inheritDotParams","@inheritParams","@inheritSection","@keywords","@md","@method","@name","@noMd","@noRd","@note","@param","@rawNamespace","@rawRd","@rdname","@references","@return","@S3method","@section","@seealso","@setClass","@slot","@source","@template","@templateVar","@title","@TODO","@usage","@useDynLib"],constants:["NULL","FALSE","TRUE","NA","Inf","NaN","NA_integer_","NA_real_","NA_complex_","NA_character_","T","F","LETTERS","letters","month.abb","month.name","pi","R.version.string"],keywords:["break","next","return","if","else","for","in","repeat","while","array","category","character","complex","double","function","integer","list","logical","matrix","numeric","vector","data.frame","factor","library","require","attach","detach","source"],special:["\\n","\\r","\\t","\\b","\\a","\\f","\\v","\\'",'\\"',"\\\\"],brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.bracket"},{open:"(",close:")",token:"delimiter.parenthesis"}],tokenizer:{root:[{include:"@numbers"},{include:"@strings"},[/[{}\[\]()]/,"@brackets"],{include:"@operators"},[/#'$/,"comment.doc"],[/#'/,"comment.doc","@roxygen"],[/(^#.*$)/,"comment"],[/\s+/,"white"],[/[,:;]/,"delimiter"],[/@[a-zA-Z]\w*/,"tag"],[/[a-zA-Z]\w*/,{cases:{"@keywords":"keyword","@constants":"constant","@default":"identifier"}}]],roxygen:[[/@\w+/,{cases:{"@roxygen":"tag","@eos":{token:"comment.doc",next:"@pop"},"@default":"comment.doc"}}],[/\s+/,{cases:{"@eos":{token:"comment.doc",next:"@pop"},"@default":"comment.doc"}}],[/.*/,{token:"comment.doc",next:"@pop"}]],numbers:[[/0[xX][0-9a-fA-F]+/,"number.hex"],[/-?(\d*\.)?\d+([eE][+\-]?\d+)?/,"number"]],operators:[[/<{1,2}-/,"operator"],[/->{1,2}/,"operator"],[/%[^%\s]+%/,"operator"],[/\*\*/,"operator"],[/%%/,"operator"],[/&&/,"operator"],[/\|\|/,"operator"],[/<>/,"operator"],[/[-+=&|!<>^~*/:$]/,"operator"]],strings:[[/'/,"string.escape","@stringBody"],[/"/,"string.escape","@dblStringBody"]],stringBody:[[/\\./,{cases:{"@special":"string","@default":"error-token"}}],[/'/,"string.escape","@popall"],[/./,"string"]],dblStringBody:[[/\\./,{cases:{"@special":"string","@default":"error-token"}}],[/"/,"string.escape","@popall"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/902.a1b90b1b.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/86658.6a6caa74.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/902.a1b90b1b.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/86658.6a6caa74.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/86814.c1a521f5.chunk.js b/ydb/core/viewer/monitoring/static/js/86814.c1a521f5.chunk.js new file mode 100644 index 000000000000..8cadba955df1 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/86814.c1a521f5.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[86814],{45709:e=>{function n(e){e.languages.bicep={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?(?:\*\/|$)/,lookbehind:!0,greedy:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0,greedy:!0}],property:[{pattern:/([\r\n][ \t]*)[a-z_]\w*(?=[ \t]*:)/i,lookbehind:!0},{pattern:/([\r\n][ \t]*)'(?:\\.|\$(?!\{)|[^'\\\r\n$])*'(?=[ \t]*:)/,lookbehind:!0,greedy:!0}],string:[{pattern:/'''[^'][\s\S]*?'''/,greedy:!0},{pattern:/(^|[^\\'])'(?:\\.|\$(?!\{)|[^'\\\r\n$])*'/,lookbehind:!0,greedy:!0}],"interpolated-string":{pattern:/(^|[^\\'])'(?:\\.|\$(?:(?!\{)|\{[^{}\r\n]*\})|[^'\\\r\n$])*'/,lookbehind:!0,greedy:!0,inside:{interpolation:{pattern:/\$\{[^{}\r\n]*\}/,inside:{expression:{pattern:/(^\$\{)[\s\S]+(?=\}$)/,lookbehind:!0},punctuation:/^\$\{|\}$/}},string:/[\s\S]+/}},datatype:{pattern:/(\b(?:output|param)\b[ \t]+\w+[ \t]+)\w+\b/,lookbehind:!0,alias:"class-name"},boolean:/\b(?:false|true)\b/,keyword:/\b(?:existing|for|if|in|module|null|output|param|resource|targetScope|var)\b/,decorator:/@\w+\b/,function:/\b[a-z_]\w*(?=[ \t]*\()/i,number:/(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:E[+-]?\d+)?/i,operator:/--|\+\+|\*\*=?|=>|&&=?|\|\|=?|[!=]==|<<=?|>>>?=?|[-+*/%&|^!=<>]=?|\.{3}|\?\?=?|\?\.?|[~:]/,punctuation:/[{}[\];(),.:]/},e.languages.bicep["interpolated-string"].inside.interpolation.inside.expression.inside=e.languages.bicep}e.exports=n,n.displayName="bicep",n.aliases=[]},86814:(e,n,t)=>{t.d(n,{default:()=>r});var i=t(45709);const r=t.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8706.755fcb81.chunk.js b/ydb/core/viewer/monitoring/static/js/8706.755fcb81.chunk.js deleted file mode 100644 index 81403fe87230..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8706.755fcb81.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8706],{88706:function(Y,M,_){Y.exports=function(Y){"use strict";function M(Y){return Y&&"object"==typeof Y&&"default"in Y?Y:{default:Y}}var _=M(Y),d={s:"\u05de\u05e1\u05e4\u05e8 \u05e9\u05e0\u05d9\u05d5\u05ea",ss:"%d \u05e9\u05e0\u05d9\u05d5\u05ea",m:"\u05d3\u05e7\u05d4",mm:"%d \u05d3\u05e7\u05d5\u05ea",h:"\u05e9\u05e2\u05d4",hh:"%d \u05e9\u05e2\u05d5\u05ea",hh2:"\u05e9\u05e2\u05ea\u05d9\u05d9\u05dd",d:"\u05d9\u05d5\u05dd",dd:"%d \u05d9\u05de\u05d9\u05dd",dd2:"\u05d9\u05d5\u05de\u05d9\u05d9\u05dd",M:"\u05d7\u05d5\u05d3\u05e9",MM:"%d \u05d7\u05d5\u05d3\u05e9\u05d9\u05dd",MM2:"\u05d7\u05d5\u05d3\u05e9\u05d9\u05d9\u05dd",y:"\u05e9\u05e0\u05d4",yy:"%d \u05e9\u05e0\u05d9\u05dd",yy2:"\u05e9\u05e0\u05ea\u05d9\u05d9\u05dd"};function l(Y,M,_){return(d[_+(2===Y?"2":"")]||d[_]).replace("%d",Y)}var m={name:"he",weekdays:"\u05e8\u05d0\u05e9\u05d5\u05df_\u05e9\u05e0\u05d9_\u05e9\u05dc\u05d9\u05e9\u05d9_\u05e8\u05d1\u05d9\u05e2\u05d9_\u05d7\u05de\u05d9\u05e9\u05d9_\u05e9\u05d9\u05e9\u05d9_\u05e9\u05d1\u05ea".split("_"),weekdaysShort:"\u05d0\u05f3_\u05d1\u05f3_\u05d2\u05f3_\u05d3\u05f3_\u05d4\u05f3_\u05d5\u05f3_\u05e9\u05f3".split("_"),weekdaysMin:"\u05d0\u05f3_\u05d1\u05f3_\u05d2\u05f3_\u05d3\u05f3_\u05d4\u05f3_\u05d5_\u05e9\u05f3".split("_"),months:"\u05d9\u05e0\u05d5\u05d0\u05e8_\u05e4\u05d1\u05e8\u05d5\u05d0\u05e8_\u05de\u05e8\u05e5_\u05d0\u05e4\u05e8\u05d9\u05dc_\u05de\u05d0\u05d9_\u05d9\u05d5\u05e0\u05d9_\u05d9\u05d5\u05dc\u05d9_\u05d0\u05d5\u05d2\u05d5\u05e1\u05d8_\u05e1\u05e4\u05d8\u05de\u05d1\u05e8_\u05d0\u05d5\u05e7\u05d8\u05d5\u05d1\u05e8_\u05e0\u05d5\u05d1\u05de\u05d1\u05e8_\u05d3\u05e6\u05de\u05d1\u05e8".split("_"),monthsShort:"\u05d9\u05e0\u05d5_\u05e4\u05d1\u05e8_\u05de\u05e8\u05e5_\u05d0\u05e4\u05e8_\u05de\u05d0\u05d9_\u05d9\u05d5\u05e0_\u05d9\u05d5\u05dc_\u05d0\u05d5\u05d2_\u05e1\u05e4\u05d8_\u05d0\u05d5\u05e7_\u05e0\u05d5\u05d1_\u05d3\u05e6\u05de".split("_"),relativeTime:{future:"\u05d1\u05e2\u05d5\u05d3 %s",past:"\u05dc\u05e4\u05e0\u05d9 %s",s:l,m:l,mm:l,h:l,hh:l,d:l,dd:l,M:l,MM:l,y:l,yy:l},ordinal:function(Y){return Y},format:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D [\u05d1]MMMM YYYY",LLL:"D [\u05d1]MMMM YYYY HH:mm",LLLL:"dddd, D [\u05d1]MMMM YYYY HH:mm",l:"D/M/YYYY",ll:"D MMM YYYY",lll:"D MMM YYYY HH:mm",llll:"ddd, D MMM YYYY HH:mm"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D [\u05d1]MMMM YYYY",LLL:"D [\u05d1]MMMM YYYY HH:mm",LLLL:"dddd, D [\u05d1]MMMM YYYY HH:mm",l:"D/M/YYYY",ll:"D MMM YYYY",lll:"D MMM YYYY HH:mm",llll:"ddd, D MMM YYYY HH:mm"}};return _.default.locale(m,null,!0),m}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/87138.cf3f482b.chunk.js b/ydb/core/viewer/monitoring/static/js/87138.cf3f482b.chunk.js new file mode 100644 index 000000000000..cc7713ac5b4f --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/87138.cf3f482b.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[87138],{28051:e=>{function n(e){e.languages.elixir={doc:{pattern:/@(?:doc|moduledoc)\s+(?:("""|''')[\s\S]*?\1|("|')(?:\\(?:\r\n|[\s\S])|(?!\2)[^\\\r\n])*\2)/,inside:{attribute:/^@\w+/,string:/['"][\s\S]+/}},comment:{pattern:/#.*/,greedy:!0},regex:{pattern:/~[rR](?:("""|''')(?:\\[\s\S]|(?!\1)[^\\])+\1|([\/|"'])(?:\\.|(?!\2)[^\\\r\n])+\2|\((?:\\.|[^\\)\r\n])+\)|\[(?:\\.|[^\\\]\r\n])+\]|\{(?:\\.|[^\\}\r\n])+\}|<(?:\\.|[^\\>\r\n])+>)[uismxfr]*/,greedy:!0},string:[{pattern:/~[cCsSwW](?:("""|''')(?:\\[\s\S]|(?!\1)[^\\])+\1|([\/|"'])(?:\\.|(?!\2)[^\\\r\n])+\2|\((?:\\.|[^\\)\r\n])+\)|\[(?:\\.|[^\\\]\r\n])+\]|\{(?:\\.|#\{[^}]+\}|#(?!\{)|[^#\\}\r\n])+\}|<(?:\\.|[^\\>\r\n])+>)[csa]?/,greedy:!0,inside:{}},{pattern:/("""|''')[\s\S]*?\1/,greedy:!0,inside:{}},{pattern:/("|')(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0,inside:{}}],atom:{pattern:/(^|[^:]):\w+/,lookbehind:!0,alias:"symbol"},module:{pattern:/\b[A-Z]\w*\b/,alias:"class-name"},"attr-name":/\b\w+\??:(?!:)/,argument:{pattern:/(^|[^&])&\d+/,lookbehind:!0,alias:"variable"},attribute:{pattern:/@\w+/,alias:"variable"},function:/\b[_a-zA-Z]\w*[?!]?(?:(?=\s*(?:\.\s*)?\()|(?=\/\d))/,number:/\b(?:0[box][a-f\d_]+|\d[\d_]*)(?:\.[\d_]+)?(?:e[+-]?[\d_]+)?\b/i,keyword:/\b(?:after|alias|and|case|catch|cond|def(?:callback|delegate|exception|impl|macro|module|n|np|p|protocol|struct)?|do|else|end|fn|for|if|import|not|or|quote|raise|require|rescue|try|unless|unquote|use|when)\b/,boolean:/\b(?:false|nil|true)\b/,operator:[/\bin\b|&&?|\|[|>]?|\\\\|::|\.\.\.?|\+\+?|-[->]?|<[-=>]|>=|!==?|\B!|=(?:==?|[>~])?|[*\/^]/,{pattern:/([^<])<(?!<)/,lookbehind:!0},{pattern:/([^>])>(?!>)/,lookbehind:!0}],punctuation:/<<|>>|[.,%\[\]{}()]/},e.languages.elixir.string.forEach((function(n){n.inside={interpolation:{pattern:/#\{[^}]+\}/,inside:{delimiter:{pattern:/^#\{|\}$/,alias:"punctuation"},rest:e.languages.elixir}}}}))}e.exports=n,n.displayName="elixir",n.aliases=[]},87138:(e,n,a)=>{a.d(n,{default:()=>t});var r=a(28051);const t=a.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/87233.c8b49edb.chunk.js b/ydb/core/viewer/monitoring/static/js/87233.c8b49edb.chunk.js new file mode 100644 index 000000000000..2191e1a3e68a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/87233.c8b49edb.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[87233],{70502:E=>{function T(E){E.languages.sql={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|(?:--|\/\/|#).*)/,lookbehind:!0},variable:[{pattern:/@(["'`])(?:\\[\s\S]|(?!\1)[^\\])+\1/,greedy:!0},/@[\w.$]+/],string:{pattern:/(^|[^@\\])("|')(?:\\[\s\S]|(?!\2)[^\\]|\2\2)*\2/,greedy:!0,lookbehind:!0},identifier:{pattern:/(^|[^@\\])`(?:\\[\s\S]|[^`\\]|``)*`/,greedy:!0,lookbehind:!0,inside:{punctuation:/^`|`$/}},function:/\b(?:AVG|COUNT|FIRST|FORMAT|LAST|LCASE|LEN|MAX|MID|MIN|MOD|NOW|ROUND|SUM|UCASE)(?=\s*\()/i,keyword:/\b(?:ACTION|ADD|AFTER|ALGORITHM|ALL|ALTER|ANALYZE|ANY|APPLY|AS|ASC|AUTHORIZATION|AUTO_INCREMENT|BACKUP|BDB|BEGIN|BERKELEYDB|BIGINT|BINARY|BIT|BLOB|BOOL|BOOLEAN|BREAK|BROWSE|BTREE|BULK|BY|CALL|CASCADED?|CASE|CHAIN|CHAR(?:ACTER|SET)?|CHECK(?:POINT)?|CLOSE|CLUSTERED|COALESCE|COLLATE|COLUMNS?|COMMENT|COMMIT(?:TED)?|COMPUTE|CONNECT|CONSISTENT|CONSTRAINT|CONTAINS(?:TABLE)?|CONTINUE|CONVERT|CREATE|CROSS|CURRENT(?:_DATE|_TIME|_TIMESTAMP|_USER)?|CURSOR|CYCLE|DATA(?:BASES?)?|DATE(?:TIME)?|DAY|DBCC|DEALLOCATE|DEC|DECIMAL|DECLARE|DEFAULT|DEFINER|DELAYED|DELETE|DELIMITERS?|DENY|DESC|DESCRIBE|DETERMINISTIC|DISABLE|DISCARD|DISK|DISTINCT|DISTINCTROW|DISTRIBUTED|DO|DOUBLE|DROP|DUMMY|DUMP(?:FILE)?|DUPLICATE|ELSE(?:IF)?|ENABLE|ENCLOSED|END|ENGINE|ENUM|ERRLVL|ERRORS|ESCAPED?|EXCEPT|EXEC(?:UTE)?|EXISTS|EXIT|EXPLAIN|EXTENDED|FETCH|FIELDS|FILE|FILLFACTOR|FIRST|FIXED|FLOAT|FOLLOWING|FOR(?: EACH ROW)?|FORCE|FOREIGN|FREETEXT(?:TABLE)?|FROM|FULL|FUNCTION|GEOMETRY(?:COLLECTION)?|GLOBAL|GOTO|GRANT|GROUP|HANDLER|HASH|HAVING|HOLDLOCK|HOUR|IDENTITY(?:COL|_INSERT)?|IF|IGNORE|IMPORT|INDEX|INFILE|INNER|INNODB|INOUT|INSERT|INT|INTEGER|INTERSECT|INTERVAL|INTO|INVOKER|ISOLATION|ITERATE|JOIN|KEYS?|KILL|LANGUAGE|LAST|LEAVE|LEFT|LEVEL|LIMIT|LINENO|LINES|LINESTRING|LOAD|LOCAL|LOCK|LONG(?:BLOB|TEXT)|LOOP|MATCH(?:ED)?|MEDIUM(?:BLOB|INT|TEXT)|MERGE|MIDDLEINT|MINUTE|MODE|MODIFIES|MODIFY|MONTH|MULTI(?:LINESTRING|POINT|POLYGON)|NATIONAL|NATURAL|NCHAR|NEXT|NO|NONCLUSTERED|NULLIF|NUMERIC|OFF?|OFFSETS?|ON|OPEN(?:DATASOURCE|QUERY|ROWSET)?|OPTIMIZE|OPTION(?:ALLY)?|ORDER|OUT(?:ER|FILE)?|OVER|PARTIAL|PARTITION|PERCENT|PIVOT|PLAN|POINT|POLYGON|PRECEDING|PRECISION|PREPARE|PREV|PRIMARY|PRINT|PRIVILEGES|PROC(?:EDURE)?|PUBLIC|PURGE|QUICK|RAISERROR|READS?|REAL|RECONFIGURE|REFERENCES|RELEASE|RENAME|REPEAT(?:ABLE)?|REPLACE|REPLICATION|REQUIRE|RESIGNAL|RESTORE|RESTRICT|RETURN(?:ING|S)?|REVOKE|RIGHT|ROLLBACK|ROUTINE|ROW(?:COUNT|GUIDCOL|S)?|RTREE|RULE|SAVE(?:POINT)?|SCHEMA|SECOND|SELECT|SERIAL(?:IZABLE)?|SESSION(?:_USER)?|SET(?:USER)?|SHARE|SHOW|SHUTDOWN|SIMPLE|SMALLINT|SNAPSHOT|SOME|SONAME|SQL|START(?:ING)?|STATISTICS|STATUS|STRIPED|SYSTEM_USER|TABLES?|TABLESPACE|TEMP(?:ORARY|TABLE)?|TERMINATED|TEXT(?:SIZE)?|THEN|TIME(?:STAMP)?|TINY(?:BLOB|INT|TEXT)|TOP?|TRAN(?:SACTIONS?)?|TRIGGER|TRUNCATE|TSEQUAL|TYPES?|UNBOUNDED|UNCOMMITTED|UNDEFINED|UNION|UNIQUE|UNLOCK|UNPIVOT|UNSIGNED|UPDATE(?:TEXT)?|USAGE|USE|USER|USING|VALUES?|VAR(?:BINARY|CHAR|CHARACTER|YING)|VIEW|WAITFOR|WARNINGS|WHEN|WHERE|WHILE|WITH(?: ROLLUP|IN)?|WORK|WRITE(?:TEXT)?|YEAR)\b/i,boolean:/\b(?:FALSE|NULL|TRUE)\b/i,number:/\b0x[\da-f]+\b|\b\d+(?:\.\d*)?|\B\.\d+\b/i,operator:/[-+*\/=%^~]|&&?|\|\|?|!=?|<(?:=>?|<|>)?|>[>=]?|\b(?:AND|BETWEEN|DIV|ILIKE|IN|IS|LIKE|NOT|OR|REGEXP|RLIKE|SOUNDS LIKE|XOR)\b/i,punctuation:/[;[\]()`,.]/}}E.exports=T,T.displayName="sql",T.aliases=[]},87233:(E,T,I)=>{I.d(T,{default:()=>R});var N=I(70502);const R=I.n(N)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/87357.d4031306.chunk.js b/ydb/core/viewer/monitoring/static/js/87357.d4031306.chunk.js new file mode 100644 index 000000000000..b3e095787954 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/87357.d4031306.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[87357],{31422:e=>{function a(e){e.languages.ada={comment:/--.*/,string:/"(?:""|[^"\r\f\n])*"/,number:[{pattern:/\b\d(?:_?\d)*#[\dA-F](?:_?[\dA-F])*(?:\.[\dA-F](?:_?[\dA-F])*)?#(?:E[+-]?\d(?:_?\d)*)?/i},{pattern:/\b\d(?:_?\d)*(?:\.\d(?:_?\d)*)?(?:E[+-]?\d(?:_?\d)*)?\b/i}],"attr-name":/\b'\w+/,keyword:/\b(?:abort|abs|abstract|accept|access|aliased|all|and|array|at|begin|body|case|constant|declare|delay|delta|digits|do|else|elsif|end|entry|exception|exit|for|function|generic|goto|if|in|interface|is|limited|loop|mod|new|not|null|of|others|out|overriding|package|pragma|private|procedure|protected|raise|range|record|rem|renames|requeue|return|reverse|select|separate|some|subtype|synchronized|tagged|task|terminate|then|type|until|use|when|while|with|xor)\b/i,boolean:/\b(?:false|true)\b/i,operator:/<[=>]?|>=?|=>?|:=|\/=?|\*\*?|[&+-]/,punctuation:/\.\.?|[,;():]/,char:/'.'/,variable:/\b[a-z](?:\w)*\b/i}}e.exports=a,a.displayName="ada",a.aliases=[]},87357:(e,a,t)=>{t.d(a,{default:()=>d});var r=t(31422);const d=t.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/87429.3792c589.chunk.js b/ydb/core/viewer/monitoring/static/js/87429.3792c589.chunk.js new file mode 100644 index 000000000000..8fe8239a41cf --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/87429.3792c589.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[87429],{41940:(e,n,t)=>{var a=t(51572);function r(e){e.register(a),function(e){e.languages.smarty={comment:{pattern:/^\{\*[\s\S]*?\*\}/,greedy:!0},"embedded-php":{pattern:/^\{php\}[\s\S]*?\{\/php\}/,greedy:!0,inside:{smarty:{pattern:/^\{php\}|\{\/php\}$/,inside:null},php:{pattern:/[\s\S]+/,alias:"language-php",inside:e.languages.php}}},string:[{pattern:/"(?:\\.|[^"\\\r\n])*"/,greedy:!0,inside:{interpolation:{pattern:/\{[^{}]*\}|`[^`]*`/,inside:{"interpolation-punctuation":{pattern:/^[{`]|[`}]$/,alias:"punctuation"},expression:{pattern:/[\s\S]+/,inside:null}}},variable:/\$\w+/}},{pattern:/'(?:\\.|[^'\\\r\n])*'/,greedy:!0}],keyword:{pattern:/(^\{\/?)[a-z_]\w*\b(?!\()/i,lookbehind:!0,greedy:!0},delimiter:{pattern:/^\{\/?|\}$/,greedy:!0,alias:"punctuation"},number:/\b0x[\dA-Fa-f]+|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee][-+]?\d+)?/,variable:[/\$(?!\d)\w+/,/#(?!\d)\w+#/,{pattern:/(\.|->|\w\s*=)(?!\d)\w+\b(?!\()/,lookbehind:!0},{pattern:/(\[)(?!\d)\w+(?=\])/,lookbehind:!0}],function:{pattern:/(\|\s*)@?[a-z_]\w*|\b[a-z_]\w*(?=\()/i,lookbehind:!0},"attr-name":/\b[a-z_]\w*(?=\s*=)/i,boolean:/\b(?:false|no|off|on|true|yes)\b/,punctuation:/[\[\](){}.,:`]|->/,operator:[/[+\-*\/%]|==?=?|[!<>]=?|&&|\|\|?/,/\bis\s+(?:not\s+)?(?:div|even|odd)(?:\s+by)?\b/,/\b(?:and|eq|gt?e|gt|lt?e|lt|mod|neq?|not|or)\b/]},e.languages.smarty["embedded-php"].inside.smarty.inside=e.languages.smarty,e.languages.smarty.string[0].inside.interpolation.inside.expression.inside=e.languages.smarty;var n=/"(?:\\.|[^"\\\r\n])*"|'(?:\\.|[^'\\\r\n])*'/,t=RegExp(/\{\*[\s\S]*?\*\}/.source+"|"+/\{php\}[\s\S]*?\{\/php\}/.source+"|"+/\{(?:[^{}"']||\{(?:[^{}"']||\{(?:[^{}"']|)*\})*\})*\}/.source.replace(//g,(function(){return n.source})),"g");e.hooks.add("before-tokenize",(function(n){var a=!1;e.languages["markup-templating"].buildPlaceholders(n,"smarty",t,(function(e){return"{/literal}"===e&&(a=!1),!a&&("{literal}"===e&&(a=!0),!0)}))})),e.hooks.add("after-tokenize",(function(n){e.languages["markup-templating"].tokenizePlaceholders(n,"smarty")}))}(e)}e.exports=r,r.displayName="smarty",r.aliases=[]},51572:e=>{function n(e){!function(e){function n(e,n){return"___"+e.toUpperCase()+n+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,a,r,i){if(t.language===a){var s=t.tokenStack=[];t.code=t.code.replace(r,(function(e){if("function"===typeof i&&!i(e))return e;for(var r,o=s.length;-1!==t.code.indexOf(r=n(a,o));)++o;return s[o]=e,r})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,a){if(t.language===a&&t.tokenStack){t.grammar=e.languages[a];var r=0,i=Object.keys(t.tokenStack);!function s(o){for(var p=0;p=i.length);p++){var l=o[p];if("string"===typeof l||l.content&&"string"===typeof l.content){var u=i[r],d=t.tokenStack[u],g="string"===typeof l?l:l.content,c=n(a,u),b=g.indexOf(c);if(b>-1){++r;var f=g.substring(0,b),m=new e.Token(a,e.tokenize(d,t.grammar),"language-"+a,d),h=g.substring(b+c.length),k=[];f&&k.push.apply(k,s([f])),k.push(m),h&&k.push.apply(k,s([h])),"string"===typeof l?o.splice.apply(o,[p,1].concat(k)):l.content=k}}else l.content&&s(l.content)}return o}(t.tokens)}}}})}(e)}e.exports=n,n.displayName="markupTemplating",n.aliases=[]},87429:(e,n,t)=>{t.d(n,{default:()=>r});var a=t(41940);const r=t.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/87962.2094d7c1.chunk.js b/ydb/core/viewer/monitoring/static/js/87962.2094d7c1.chunk.js new file mode 100644 index 000000000000..f24bc79aa14d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/87962.2094d7c1.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[87962],{87962:function(e,_,i){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var i=_(e),n={name:"fr-ca",weekdays:"dimanche_lundi_mardi_mercredi_jeudi_vendredi_samedi".split("_"),months:"janvier_f\xe9vrier_mars_avril_mai_juin_juillet_ao\xfbt_septembre_octobre_novembre_d\xe9cembre".split("_"),weekdaysShort:"dim._lun._mar._mer._jeu._ven._sam.".split("_"),monthsShort:"janv._f\xe9vr._mars_avr._mai_juin_juil._ao\xfbt_sept._oct._nov._d\xe9c.".split("_"),weekdaysMin:"di_lu_ma_me_je_ve_sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},relativeTime:{future:"dans %s",past:"il y a %s",s:"quelques secondes",m:"une minute",mm:"%d minutes",h:"une heure",hh:"%d heures",d:"un jour",dd:"%d jours",M:"un mois",MM:"%d mois",y:"un an",yy:"%d ans"}};return i.default.locale(n,null,!0),n}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88081.e48ec099.chunk.js b/ydb/core/viewer/monitoring/static/js/88081.e48ec099.chunk.js new file mode 100644 index 000000000000..464dd4ba92c6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88081.e48ec099.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88081],{88081:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-kw",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648\u0632_\u063a\u0634\u062a_\u0634\u062a\u0646\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0646\u0628\u0631_\u062f\u062c\u0646\u0628\u0631".split("_"),weekdaysShort:"\u0627\u062d\u062f_\u0627\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648\u0632_\u063a\u0634\u062a_\u0634\u062a\u0646\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0646\u0628\u0631_\u062f\u062c\u0646\u0628\u0631".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88119.041d294e.chunk.js b/ydb/core/viewer/monitoring/static/js/88119.041d294e.chunk.js new file mode 100644 index 000000000000..3fbbba4533bd --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88119.041d294e.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88119],{88119:function(e,_,s){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var s=_(e),o={name:"es-mx",weekdays:"domingo_lunes_martes_mi\xe9rcoles_jueves_viernes_s\xe1bado".split("_"),weekdaysShort:"dom._lun._mar._mi\xe9._jue._vie._s\xe1b.".split("_"),weekdaysMin:"do_lu_ma_mi_ju_vi_s\xe1".split("_"),months:"enero_febrero_marzo_abril_mayo_junio_julio_agosto_septiembre_octubre_noviembre_diciembre".split("_"),monthsShort:"ene_feb_mar_abr_may_jun_jul_ago_sep_oct_nov_dic".split("_"),relativeTime:{future:"en %s",past:"hace %s",s:"unos segundos",m:"un minuto",mm:"%d minutos",h:"una hora",hh:"%d horas",d:"un d\xeda",dd:"%d d\xedas",M:"un mes",MM:"%d meses",y:"un a\xf1o",yy:"%d a\xf1os"},ordinal:function(e){return e+"\xba"},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY H:mm",LLLL:"dddd, D [de] MMMM [de] YYYY H:mm"}};return s.default.locale(o,null,!0),o}(s(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8821.96eeccd6.chunk.js b/ydb/core/viewer/monitoring/static/js/8821.96eeccd6.chunk.js deleted file mode 100644 index 69d2fe5ac227..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8821.96eeccd6.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 8821.96eeccd6.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8821],{68821:(e,t,n)=>{n.r(t),n.d(t,{CompletionAdapter:()=>Ht,DefinitionAdapter:()=>Zt,DiagnosticsAdapter:()=>Ot,DocumentColorAdapter:()=>ln,DocumentFormattingEditProvider:()=>un,DocumentHighlightAdapter:()=>Jt,DocumentLinkAdapter:()=>sn,DocumentRangeFormattingEditProvider:()=>cn,DocumentSymbolAdapter:()=>rn,FoldingRangeAdapter:()=>gn,HoverAdapter:()=>qt,ReferenceAdapter:()=>tn,RenameAdapter:()=>nn,SelectionRangeAdapter:()=>fn,WorkerManager:()=>Nt,fromPosition:()=>Kt,fromRange:()=>Xt,setupMode:()=>pn,setupMode1:()=>hn,toRange:()=>zt,toTextEdit:()=>Bt});var r,i,o=n(80781),a=Object.defineProperty,s=Object.getOwnPropertyDescriptor,u=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,d=(e,t,n,r)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of u(t))c.call(e,i)||i===n||a(e,i,{get:()=>t[i],enumerable:!(r=s(t,i))||r.enumerable});return e},l={};d(l,r=o,"default"),i&&d(i,r,"default");var g,f,m,h,p,v,b,_,k,w,y,x,I,E,S,A,C,R,L,T,M,P,D,F,j,N,U,V,O,W,H,K,X,z,$,B,q,Q,G,J,Y,Z,ee,te,ne,re,ie,oe,ae,se,ue,ce,de,le,ge,fe,me,he,pe,ve,be,_e,ke,we,ye,xe,Ie,Ee,Se,Ae,Ce,Re,Le,Te,Me,Pe,De,Fe,je,Ne,Ue,Ve,Oe,We,He,Ke,Xe,ze,$e,Be,qe,Qe,Ge,Je,Ye,Ze,et,tt,nt,rt,it,ot,at,st,ut,ct,dt,lt,gt,ft,mt,ht,pt,vt,bt,_t,kt,wt,yt,xt,It,Et,St,At,Ct,Rt,Lt,Tt,Mt,Pt,Dt,Ft,jt,Nt=class{constructor(e){this._defaults=e,this._worker=null,this._client=null,this._idleCheckInterval=window.setInterval((()=>this._checkIfIdle()),3e4),this._lastUsedTime=0,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker()))}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}dispose(){clearInterval(this._idleCheckInterval),this._configChangeListener.dispose(),this._stopWorker()}_checkIfIdle(){if(!this._worker)return;Date.now()-this._lastUsedTime>12e4&&this._stopWorker()}_getClient(){return this._lastUsedTime=Date.now(),this._client||(this._worker=l.editor.createWebWorker({moduleId:"vs/language/html/htmlWorker",createData:{languageSettings:this._defaults.options,languageId:this._defaults.languageId},label:this._defaults.languageId}),this._client=this._worker.getProxy()),this._client}getLanguageServiceWorker(...e){let t;return this._getClient().then((e=>{t=e})).then((t=>{if(this._worker)return this._worker.withSyncedResources(e)})).then((e=>t))}};(g||(g={})).is=function(e){return"string"===typeof e},(f||(f={})).is=function(e){return"string"===typeof e},(h=m||(m={})).MIN_VALUE=-2147483648,h.MAX_VALUE=2147483647,h.is=function(e){return"number"===typeof e&&h.MIN_VALUE<=e&&e<=h.MAX_VALUE},(v=p||(p={})).MIN_VALUE=0,v.MAX_VALUE=2147483647,v.is=function(e){return"number"===typeof e&&v.MIN_VALUE<=e&&e<=v.MAX_VALUE},(_=b||(b={})).create=function(e,t){return e===Number.MAX_VALUE&&(e=p.MAX_VALUE),t===Number.MAX_VALUE&&(t=p.MAX_VALUE),{line:e,character:t}},_.is=function(e){let t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.line)&&Ut.uinteger(t.character)},(w=k||(k={})).create=function(e,t,n,r){if(Ut.uinteger(e)&&Ut.uinteger(t)&&Ut.uinteger(n)&&Ut.uinteger(r))return{start:b.create(e,t),end:b.create(n,r)};if(b.is(e)&&b.is(t))return{start:e,end:t};throw new Error(`Range#create called with invalid arguments[${e}, ${t}, ${n}, ${r}]`)},w.is=function(e){let t=e;return Ut.objectLiteral(t)&&b.is(t.start)&&b.is(t.end)},(x=y||(y={})).create=function(e,t){return{uri:e,range:t}},x.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(Ut.string(t.uri)||Ut.undefined(t.uri))},(E=I||(I={})).create=function(e,t,n,r){return{targetUri:e,targetRange:t,targetSelectionRange:n,originSelectionRange:r}},E.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.targetRange)&&Ut.string(t.targetUri)&&k.is(t.targetSelectionRange)&&(k.is(t.originSelectionRange)||Ut.undefined(t.originSelectionRange))},(A=S||(S={})).create=function(e,t,n,r){return{red:e,green:t,blue:n,alpha:r}},A.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.numberRange(t.red,0,1)&&Ut.numberRange(t.green,0,1)&&Ut.numberRange(t.blue,0,1)&&Ut.numberRange(t.alpha,0,1)},(R=C||(C={})).create=function(e,t){return{range:e,color:t}},R.is=function(e){const t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&S.is(t.color)},(T=L||(L={})).create=function(e,t,n){return{label:e,textEdit:t,additionalTextEdits:n}},T.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.undefined(t.textEdit)||B.is(t))&&(Ut.undefined(t.additionalTextEdits)||Ut.typedArray(t.additionalTextEdits,B.is))},(P=M||(M={})).Comment="comment",P.Imports="imports",P.Region="region",(F=D||(D={})).create=function(e,t,n,r,i,o){const a={startLine:e,endLine:t};return Ut.defined(n)&&(a.startCharacter=n),Ut.defined(r)&&(a.endCharacter=r),Ut.defined(i)&&(a.kind=i),Ut.defined(o)&&(a.collapsedText=o),a},F.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.uinteger(t.startLine)&&Ut.uinteger(t.startLine)&&(Ut.undefined(t.startCharacter)||Ut.uinteger(t.startCharacter))&&(Ut.undefined(t.endCharacter)||Ut.uinteger(t.endCharacter))&&(Ut.undefined(t.kind)||Ut.string(t.kind))},(N=j||(j={})).create=function(e,t){return{location:e,message:t}},N.is=function(e){let t=e;return Ut.defined(t)&&y.is(t.location)&&Ut.string(t.message)},(V=U||(U={})).Error=1,V.Warning=2,V.Information=3,V.Hint=4,(W=O||(O={})).Unnecessary=1,W.Deprecated=2,(H||(H={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.href)},(X=K||(K={})).create=function(e,t,n,r,i,o){let a={range:e,message:t};return Ut.defined(n)&&(a.severity=n),Ut.defined(r)&&(a.code=r),Ut.defined(i)&&(a.source=i),Ut.defined(o)&&(a.relatedInformation=o),a},X.is=function(e){var t;let n=e;return Ut.defined(n)&&k.is(n.range)&&Ut.string(n.message)&&(Ut.number(n.severity)||Ut.undefined(n.severity))&&(Ut.integer(n.code)||Ut.string(n.code)||Ut.undefined(n.code))&&(Ut.undefined(n.codeDescription)||Ut.string(null===(t=n.codeDescription)||void 0===t?void 0:t.href))&&(Ut.string(n.source)||Ut.undefined(n.source))&&(Ut.undefined(n.relatedInformation)||Ut.typedArray(n.relatedInformation,j.is))},($=z||(z={})).create=function(e,t,...n){let r={title:e,command:t};return Ut.defined(n)&&n.length>0&&(r.arguments=n),r},$.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.title)&&Ut.string(t.command)},(q=B||(B={})).replace=function(e,t){return{range:e,newText:t}},q.insert=function(e,t){return{range:{start:e,end:e},newText:t}},q.del=function(e){return{range:e,newText:""}},q.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.newText)&&k.is(t.range)},(G=Q||(Q={})).create=function(e,t,n){const r={label:e};return void 0!==t&&(r.needsConfirmation=t),void 0!==n&&(r.description=n),r},G.is=function(e){const t=e;return Ut.objectLiteral(t)&&Ut.string(t.label)&&(Ut.boolean(t.needsConfirmation)||void 0===t.needsConfirmation)&&(Ut.string(t.description)||void 0===t.description)},(J||(J={})).is=function(e){const t=e;return Ut.string(t)},(Z=Y||(Y={})).replace=function(e,t,n){return{range:e,newText:t,annotationId:n}},Z.insert=function(e,t,n){return{range:{start:e,end:e},newText:t,annotationId:n}},Z.del=function(e,t){return{range:e,newText:"",annotationId:t}},Z.is=function(e){const t=e;return B.is(t)&&(Q.is(t.annotationId)||J.is(t.annotationId))},(te=ee||(ee={})).create=function(e,t){return{textDocument:e,edits:t}},te.is=function(e){let t=e;return Ut.defined(t)&&fe.is(t.textDocument)&&Array.isArray(t.edits)},(re=ne||(ne={})).create=function(e,t,n){let r={kind:"create",uri:e};return void 0===t||void 0===t.overwrite&&void 0===t.ignoreIfExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},re.is=function(e){let t=e;return t&&"create"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(oe=ie||(ie={})).create=function(e,t,n,r){let i={kind:"rename",oldUri:e,newUri:t};return void 0===n||void 0===n.overwrite&&void 0===n.ignoreIfExists||(i.options=n),void 0!==r&&(i.annotationId=r),i},oe.is=function(e){let t=e;return t&&"rename"===t.kind&&Ut.string(t.oldUri)&&Ut.string(t.newUri)&&(void 0===t.options||(void 0===t.options.overwrite||Ut.boolean(t.options.overwrite))&&(void 0===t.options.ignoreIfExists||Ut.boolean(t.options.ignoreIfExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(se=ae||(ae={})).create=function(e,t,n){let r={kind:"delete",uri:e};return void 0===t||void 0===t.recursive&&void 0===t.ignoreIfNotExists||(r.options=t),void 0!==n&&(r.annotationId=n),r},se.is=function(e){let t=e;return t&&"delete"===t.kind&&Ut.string(t.uri)&&(void 0===t.options||(void 0===t.options.recursive||Ut.boolean(t.options.recursive))&&(void 0===t.options.ignoreIfNotExists||Ut.boolean(t.options.ignoreIfNotExists)))&&(void 0===t.annotationId||J.is(t.annotationId))},(ue||(ue={})).is=function(e){let t=e;return t&&(void 0!==t.changes||void 0!==t.documentChanges)&&(void 0===t.documentChanges||t.documentChanges.every((e=>Ut.string(e.kind)?ne.is(e)||ie.is(e)||ae.is(e):ee.is(e))))},(de=ce||(ce={})).create=function(e){return{uri:e}},de.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)},(ge=le||(le={})).create=function(e,t){return{uri:e,version:t}},ge.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.integer(t.version)},(me=fe||(fe={})).create=function(e,t){return{uri:e,version:t}},me.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&(null===t.version||Ut.integer(t.version))},(pe=he||(he={})).create=function(e,t,n,r){return{uri:e,languageId:t,version:n,text:r}},pe.is=function(e){let t=e;return Ut.defined(t)&&Ut.string(t.uri)&&Ut.string(t.languageId)&&Ut.integer(t.version)&&Ut.string(t.text)},(be=ve||(ve={})).PlainText="plaintext",be.Markdown="markdown",be.is=function(e){const t=e;return t===be.PlainText||t===be.Markdown},(_e||(_e={})).is=function(e){const t=e;return Ut.objectLiteral(e)&&ve.is(t.kind)&&Ut.string(t.value)},(we=ke||(ke={})).Text=1,we.Method=2,we.Function=3,we.Constructor=4,we.Field=5,we.Variable=6,we.Class=7,we.Interface=8,we.Module=9,we.Property=10,we.Unit=11,we.Value=12,we.Enum=13,we.Keyword=14,we.Snippet=15,we.Color=16,we.File=17,we.Reference=18,we.Folder=19,we.EnumMember=20,we.Constant=21,we.Struct=22,we.Event=23,we.Operator=24,we.TypeParameter=25,(xe=ye||(ye={})).PlainText=1,xe.Snippet=2,(Ie||(Ie={})).Deprecated=1,(Se=Ee||(Ee={})).create=function(e,t,n){return{newText:e,insert:t,replace:n}},Se.is=function(e){const t=e;return t&&Ut.string(t.newText)&&k.is(t.insert)&&k.is(t.replace)},(Ce=Ae||(Ae={})).asIs=1,Ce.adjustIndentation=2,(Re||(Re={})).is=function(e){const t=e;return t&&(Ut.string(t.detail)||void 0===t.detail)&&(Ut.string(t.description)||void 0===t.description)},(Le||(Le={})).create=function(e){return{label:e}},(Te||(Te={})).create=function(e,t){return{items:e||[],isIncomplete:!!t}},(Pe=Me||(Me={})).fromPlainText=function(e){return e.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")},Pe.is=function(e){const t=e;return Ut.string(t)||Ut.objectLiteral(t)&&Ut.string(t.language)&&Ut.string(t.value)},(De||(De={})).is=function(e){let t=e;return!!t&&Ut.objectLiteral(t)&&(_e.is(t.contents)||Me.is(t.contents)||Ut.typedArray(t.contents,Me.is))&&(void 0===e.range||k.is(e.range))},(Fe||(Fe={})).create=function(e,t){return t?{label:e,documentation:t}:{label:e}},(je||(je={})).create=function(e,t,...n){let r={label:e};return Ut.defined(t)&&(r.documentation=t),Ut.defined(n)?r.parameters=n:r.parameters=[],r},(Ue=Ne||(Ne={})).Text=1,Ue.Read=2,Ue.Write=3,(Ve||(Ve={})).create=function(e,t){let n={range:e};return Ut.number(t)&&(n.kind=t),n},(We=Oe||(Oe={})).File=1,We.Module=2,We.Namespace=3,We.Package=4,We.Class=5,We.Method=6,We.Property=7,We.Field=8,We.Constructor=9,We.Enum=10,We.Interface=11,We.Function=12,We.Variable=13,We.Constant=14,We.String=15,We.Number=16,We.Boolean=17,We.Array=18,We.Object=19,We.Key=20,We.Null=21,We.EnumMember=22,We.Struct=23,We.Event=24,We.Operator=25,We.TypeParameter=26,(He||(He={})).Deprecated=1,(Ke||(Ke={})).create=function(e,t,n,r,i){let o={name:e,kind:t,location:{uri:r,range:n}};return i&&(o.containerName=i),o},(Xe||(Xe={})).create=function(e,t,n,r){return void 0!==r?{name:e,kind:t,location:{uri:n,range:r}}:{name:e,kind:t,location:{uri:n}}},($e=ze||(ze={})).create=function(e,t,n,r,i,o){let a={name:e,detail:t,kind:n,range:r,selectionRange:i};return void 0!==o&&(a.children=o),a},$e.is=function(e){let t=e;return t&&Ut.string(t.name)&&Ut.number(t.kind)&&k.is(t.range)&&k.is(t.selectionRange)&&(void 0===t.detail||Ut.string(t.detail))&&(void 0===t.deprecated||Ut.boolean(t.deprecated))&&(void 0===t.children||Array.isArray(t.children))&&(void 0===t.tags||Array.isArray(t.tags))},(qe=Be||(Be={})).Empty="",qe.QuickFix="quickfix",qe.Refactor="refactor",qe.RefactorExtract="refactor.extract",qe.RefactorInline="refactor.inline",qe.RefactorRewrite="refactor.rewrite",qe.Source="source",qe.SourceOrganizeImports="source.organizeImports",qe.SourceFixAll="source.fixAll",(Ge=Qe||(Qe={})).Invoked=1,Ge.Automatic=2,(Ye=Je||(Je={})).create=function(e,t,n){let r={diagnostics:e};return void 0!==t&&null!==t&&(r.only=t),void 0!==n&&null!==n&&(r.triggerKind=n),r},Ye.is=function(e){let t=e;return Ut.defined(t)&&Ut.typedArray(t.diagnostics,K.is)&&(void 0===t.only||Ut.typedArray(t.only,Ut.string))&&(void 0===t.triggerKind||t.triggerKind===Qe.Invoked||t.triggerKind===Qe.Automatic)},(et=Ze||(Ze={})).create=function(e,t,n){let r={title:e},i=!0;return"string"===typeof t?(i=!1,r.kind=t):z.is(t)?r.command=t:r.edit=t,i&&void 0!==n&&(r.kind=n),r},et.is=function(e){let t=e;return t&&Ut.string(t.title)&&(void 0===t.diagnostics||Ut.typedArray(t.diagnostics,K.is))&&(void 0===t.kind||Ut.string(t.kind))&&(void 0!==t.edit||void 0!==t.command)&&(void 0===t.command||z.is(t.command))&&(void 0===t.isPreferred||Ut.boolean(t.isPreferred))&&(void 0===t.edit||ue.is(t.edit))},(nt=tt||(tt={})).create=function(e,t){let n={range:e};return Ut.defined(t)&&(n.data=t),n},nt.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.command)||z.is(t.command))},(it=rt||(rt={})).create=function(e,t){return{tabSize:e,insertSpaces:t}},it.is=function(e){let t=e;return Ut.defined(t)&&Ut.uinteger(t.tabSize)&&Ut.boolean(t.insertSpaces)},(at=ot||(ot={})).create=function(e,t,n){return{range:e,target:t,data:n}},at.is=function(e){let t=e;return Ut.defined(t)&&k.is(t.range)&&(Ut.undefined(t.target)||Ut.string(t.target))},(ut=st||(st={})).create=function(e,t){return{range:e,parent:t}},ut.is=function(e){let t=e;return Ut.objectLiteral(t)&&k.is(t.range)&&(void 0===t.parent||ut.is(t.parent))},(dt=ct||(ct={})).namespace="namespace",dt.type="type",dt.class="class",dt.enum="enum",dt.interface="interface",dt.struct="struct",dt.typeParameter="typeParameter",dt.parameter="parameter",dt.variable="variable",dt.property="property",dt.enumMember="enumMember",dt.event="event",dt.function="function",dt.method="method",dt.macro="macro",dt.keyword="keyword",dt.modifier="modifier",dt.comment="comment",dt.string="string",dt.number="number",dt.regexp="regexp",dt.operator="operator",dt.decorator="decorator",(gt=lt||(lt={})).declaration="declaration",gt.definition="definition",gt.readonly="readonly",gt.static="static",gt.deprecated="deprecated",gt.abstract="abstract",gt.async="async",gt.modification="modification",gt.documentation="documentation",gt.defaultLibrary="defaultLibrary",(ft||(ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.resultId||"string"===typeof t.resultId)&&Array.isArray(t.data)&&(0===t.data.length||"number"===typeof t.data[0])},(ht=mt||(mt={})).create=function(e,t){return{range:e,text:t}},ht.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.string(t.text)},(vt=pt||(pt={})).create=function(e,t,n){return{range:e,variableName:t,caseSensitiveLookup:n}},vt.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&Ut.boolean(t.caseSensitiveLookup)&&(Ut.string(t.variableName)||void 0===t.variableName)},(_t=bt||(bt={})).create=function(e,t){return{range:e,expression:t}},_t.is=function(e){const t=e;return void 0!==t&&null!==t&&k.is(t.range)&&(Ut.string(t.expression)||void 0===t.expression)},(wt=kt||(kt={})).create=function(e,t){return{frameId:e,stoppedLocation:t}},wt.is=function(e){const t=e;return Ut.defined(t)&&k.is(e.stoppedLocation)},(xt=yt||(yt={})).Type=1,xt.Parameter=2,xt.is=function(e){return 1===e||2===e},(Et=It||(It={})).create=function(e){return{value:e}},Et.is=function(e){const t=e;return Ut.objectLiteral(t)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.location||y.is(t.location))&&(void 0===t.command||z.is(t.command))},(At=St||(St={})).create=function(e,t,n){const r={position:e,label:t};return void 0!==n&&(r.kind=n),r},At.is=function(e){const t=e;return Ut.objectLiteral(t)&&b.is(t.position)&&(Ut.string(t.label)||Ut.typedArray(t.label,It.is))&&(void 0===t.kind||yt.is(t.kind))&&void 0===t.textEdits||Ut.typedArray(t.textEdits,B.is)&&(void 0===t.tooltip||Ut.string(t.tooltip)||_e.is(t.tooltip))&&(void 0===t.paddingLeft||Ut.boolean(t.paddingLeft))&&(void 0===t.paddingRight||Ut.boolean(t.paddingRight))},(Ct||(Ct={})).createSnippet=function(e){return{kind:"snippet",value:e}},(Rt||(Rt={})).create=function(e,t,n,r){return{insertText:e,filterText:t,range:n,command:r}},(Lt||(Lt={})).create=function(e){return{items:e}},(Mt=Tt||(Tt={})).Invoked=0,Mt.Automatic=1,(Pt||(Pt={})).create=function(e,t){return{range:e,text:t}},(Dt||(Dt={})).create=function(e,t){return{triggerKind:e,selectedCompletionInfo:t}},(Ft||(Ft={})).is=function(e){const t=e;return Ut.objectLiteral(t)&&f.is(t.uri)&&Ut.string(t.name)},function(e){function t(e,n){if(e.length<=1)return e;const r=e.length/2|0,i=e.slice(0,r),o=e.slice(r);t(i,n),t(o,n);let a=0,s=0,u=0;for(;a{let n=e.range.start.line-t.range.start.line;return 0===n?e.range.start.character-t.range.start.character:n})),o=r.length;for(let t=i.length-1;t>=0;t--){let n=i[t],a=e.offsetAt(n.range.start),s=e.offsetAt(n.range.end);if(!(s<=o))throw new Error("Overlapping edit");r=r.substring(0,a)+n.newText+r.substring(s,r.length),o=a}return r}}(jt||(jt={}));var Ut,Vt=class{constructor(e,t,n,r){this._uri=e,this._languageId=t,this._version=n,this._content=r,this._lineOffsets=void 0}get uri(){return this._uri}get languageId(){return this._languageId}get version(){return this._version}getText(e){if(e){let t=this.offsetAt(e.start),n=this.offsetAt(e.end);return this._content.substring(t,n)}return this._content}update(e,t){this._content=e.text,this._version=t,this._lineOffsets=void 0}getLineOffsets(){if(void 0===this._lineOffsets){let e=[],t=this._content,n=!0;for(let r=0;r0&&e.push(t.length),this._lineOffsets=e}return this._lineOffsets}positionAt(e){e=Math.max(Math.min(e,this._content.length),0);let t=this.getLineOffsets(),n=0,r=t.length;if(0===r)return b.create(0,e);for(;ne?r=i:n=i+1}let i=n-1;return b.create(i,e-t[i])}offsetAt(e){let t=this.getLineOffsets();if(e.line>=t.length)return this._content.length;if(e.line<0)return 0;let n=t[e.line],r=e.line+1{let t,n=e.getLanguageId();n===this._languageId&&(this._listener[e.uri.toString()]=e.onDidChangeContent((()=>{window.clearTimeout(t),t=window.setTimeout((()=>this._doValidate(e.uri,n)),500)})),this._doValidate(e.uri,n))},i=e=>{l.editor.setModelMarkers(e,this._languageId,[]);let t=e.uri.toString(),n=this._listener[t];n&&(n.dispose(),delete this._listener[t])};this._disposables.push(l.editor.onDidCreateModel(r)),this._disposables.push(l.editor.onWillDisposeModel(i)),this._disposables.push(l.editor.onDidChangeModelLanguage((e=>{i(e.model),r(e.model)}))),this._disposables.push(n((e=>{l.editor.getModels().forEach((e=>{e.getLanguageId()===this._languageId&&(i(e),r(e))}))}))),this._disposables.push({dispose:()=>{l.editor.getModels().forEach(i);for(let e in this._listener)this._listener[e].dispose()}}),l.editor.getModels().forEach(r)}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables.length=0}_doValidate(e,t){this._worker(e).then((t=>t.doValidation(e.toString()))).then((n=>{const r=n.map((e=>function(e,t){let n="number"===typeof t.code?String(t.code):t.code;return{severity:Wt(t.severity),startLineNumber:t.range.start.line+1,startColumn:t.range.start.character+1,endLineNumber:t.range.end.line+1,endColumn:t.range.end.character+1,message:t.message,code:n,source:t.source}}(0,e)));let i=l.editor.getModel(e);i&&i.getLanguageId()===t&&l.editor.setModelMarkers(i,t,r)})).then(void 0,(e=>{console.error(e)}))}};function Wt(e){switch(e){case U.Error:return l.MarkerSeverity.Error;case U.Warning:return l.MarkerSeverity.Warning;case U.Information:return l.MarkerSeverity.Info;case U.Hint:return l.MarkerSeverity.Hint;default:return l.MarkerSeverity.Info}}var Ht=class{constructor(e,t){this._worker=e,this._triggerCharacters=t}get triggerCharacters(){return this._triggerCharacters}provideCompletionItems(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doComplete(i.toString(),Kt(t)))).then((n=>{if(!n)return;const r=e.getWordUntilPosition(t),i=new l.Range(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn),o=n.items.map((e=>{const t={label:e.label,insertText:e.insertText||e.label,sortText:e.sortText,filterText:e.filterText,documentation:e.documentation,detail:e.detail,command:(n=e.command,n&&"editor.action.triggerSuggest"===n.command?{id:n.command,title:n.title,arguments:n.arguments}:void 0),range:i,kind:$t(e.kind)};var n,r;return e.textEdit&&("undefined"!==typeof(r=e.textEdit).insert&&"undefined"!==typeof r.replace?t.range={insert:zt(e.textEdit.insert),replace:zt(e.textEdit.replace)}:t.range=zt(e.textEdit.range),t.insertText=e.textEdit.newText),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),e.insertTextFormat===ye.Snippet&&(t.insertTextRules=l.languages.CompletionItemInsertTextRule.InsertAsSnippet),t}));return{isIncomplete:n.isIncomplete,suggestions:o}}))}};function Kt(e){if(e)return{character:e.column-1,line:e.lineNumber-1}}function Xt(e){if(e)return{start:{line:e.startLineNumber-1,character:e.startColumn-1},end:{line:e.endLineNumber-1,character:e.endColumn-1}}}function zt(e){if(e)return new l.Range(e.start.line+1,e.start.character+1,e.end.line+1,e.end.character+1)}function $t(e){const t=l.languages.CompletionItemKind;switch(e){case ke.Text:return t.Text;case ke.Method:return t.Method;case ke.Function:return t.Function;case ke.Constructor:return t.Constructor;case ke.Field:return t.Field;case ke.Variable:return t.Variable;case ke.Class:return t.Class;case ke.Interface:return t.Interface;case ke.Module:return t.Module;case ke.Property:return t.Property;case ke.Unit:return t.Unit;case ke.Value:return t.Value;case ke.Enum:return t.Enum;case ke.Keyword:return t.Keyword;case ke.Snippet:return t.Snippet;case ke.Color:return t.Color;case ke.File:return t.File;case ke.Reference:return t.Reference}return t.Property}function Bt(e){if(e)return{range:zt(e.range),text:e.newText}}var qt=class{constructor(e){this._worker=e}provideHover(e,t,n){let r=e.uri;return this._worker(r).then((e=>e.doHover(r.toString(),Kt(t)))).then((e=>{if(e)return{range:zt(e.range),contents:Gt(e.contents)}}))}};function Qt(e){return"string"===typeof e?{value:e}:(t=e)&&"object"===typeof t&&"string"===typeof t.kind?"plaintext"===e.kind?{value:e.value.replace(/[\\`*_{}[\]()#+\-.!]/g,"\\$&")}:{value:e.value}:{value:"```"+e.language+"\n"+e.value+"\n```\n"};var t}function Gt(e){if(e)return Array.isArray(e)?e.map(Qt):[Qt(e)]}var Jt=class{constructor(e){this._worker=e}provideDocumentHighlights(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDocumentHighlights(r.toString(),Kt(t)))).then((e=>{if(e)return e.map((e=>({range:zt(e.range),kind:Yt(e.kind)})))}))}};function Yt(e){switch(e){case Ne.Read:return l.languages.DocumentHighlightKind.Read;case Ne.Write:return l.languages.DocumentHighlightKind.Write;case Ne.Text:return l.languages.DocumentHighlightKind.Text}return l.languages.DocumentHighlightKind.Text}var Zt=class{constructor(e){this._worker=e}provideDefinition(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.findDefinition(r.toString(),Kt(t)))).then((e=>{if(e)return[en(e)]}))}};function en(e){return{uri:l.Uri.parse(e.uri),range:zt(e.range)}}var tn=class{constructor(e){this._worker=e}provideReferences(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.findReferences(i.toString(),Kt(t)))).then((e=>{if(e)return e.map(en)}))}},nn=class{constructor(e){this._worker=e}provideRenameEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.doRename(i.toString(),Kt(t),n))).then((e=>function(e){if(!e||!e.changes)return;let t=[];for(let n in e.changes){const r=l.Uri.parse(n);for(let i of e.changes[n])t.push({resource:r,versionId:void 0,textEdit:{range:zt(i.range),text:i.newText}})}return{edits:t}}(e)))}};var rn=class{constructor(e){this._worker=e}provideDocumentSymbols(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentSymbols(n.toString()))).then((e=>{if(e)return e.map((e=>"children"in e?on(e):{name:e.name,detail:"",containerName:e.containerName,kind:an(e.kind),range:zt(e.location.range),selectionRange:zt(e.location.range),tags:[]}))}))}};function on(e){return{name:e.name,detail:e.detail??"",kind:an(e.kind),range:zt(e.range),selectionRange:zt(e.selectionRange),tags:e.tags??[],children:(e.children??[]).map((e=>on(e)))}}function an(e){let t=l.languages.SymbolKind;switch(e){case Oe.File:return t.File;case Oe.Module:return t.Module;case Oe.Namespace:return t.Namespace;case Oe.Package:return t.Package;case Oe.Class:return t.Class;case Oe.Method:return t.Method;case Oe.Property:return t.Property;case Oe.Field:return t.Field;case Oe.Constructor:return t.Constructor;case Oe.Enum:return t.Enum;case Oe.Interface:return t.Interface;case Oe.Function:return t.Function;case Oe.Variable:return t.Variable;case Oe.Constant:return t.Constant;case Oe.String:return t.String;case Oe.Number:return t.Number;case Oe.Boolean:return t.Boolean;case Oe.Array:return t.Array}return t.Function}var sn=class{constructor(e){this._worker=e}provideLinks(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentLinks(n.toString()))).then((e=>{if(e)return{links:e.map((e=>({range:zt(e.range),url:e.target})))}}))}},un=class{constructor(e){this._worker=e}provideDocumentFormattingEdits(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.format(r.toString(),null,dn(t)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}},cn=class{constructor(e){this._worker=e,this.canFormatMultipleRanges=!1}provideDocumentRangeFormattingEdits(e,t,n,r){const i=e.uri;return this._worker(i).then((e=>e.format(i.toString(),Xt(t),dn(n)).then((e=>{if(e&&0!==e.length)return e.map(Bt)}))))}};function dn(e){return{tabSize:e.tabSize,insertSpaces:e.insertSpaces}}var ln=class{constructor(e){this._worker=e}provideDocumentColors(e,t){const n=e.uri;return this._worker(n).then((e=>e.findDocumentColors(n.toString()))).then((e=>{if(e)return e.map((e=>({color:e.color,range:zt(e.range)})))}))}provideColorPresentations(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getColorPresentations(r.toString(),t.color,Xt(t.range)))).then((e=>{if(e)return e.map((e=>{let t={label:e.label};return e.textEdit&&(t.textEdit=Bt(e.textEdit)),e.additionalTextEdits&&(t.additionalTextEdits=e.additionalTextEdits.map(Bt)),t}))}))}},gn=class{constructor(e){this._worker=e}provideFoldingRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getFoldingRanges(r.toString(),t))).then((e=>{if(e)return e.map((e=>{const t={start:e.startLine+1,end:e.endLine+1};return"undefined"!==typeof e.kind&&(t.kind=function(e){switch(e){case M.Comment:return l.languages.FoldingRangeKind.Comment;case M.Imports:return l.languages.FoldingRangeKind.Imports;case M.Region:return l.languages.FoldingRangeKind.Region}return}(e.kind)),t}))}))}};var fn=class{constructor(e){this._worker=e}provideSelectionRanges(e,t,n){const r=e.uri;return this._worker(r).then((e=>e.getSelectionRanges(r.toString(),t.map(Kt)))).then((e=>{if(e)return e.map((e=>{const t=[];for(;e;)t.push({range:zt(e.range)}),e=e.parent;return t}))}))}},mn=class extends Ht{constructor(e){super(e,[".",":","<",'"',"=","/"])}};function hn(e){const t=new Nt(e),n=(...e)=>t.getLanguageServiceWorker(...e);let r=e.languageId;l.languages.registerCompletionItemProvider(r,new mn(n)),l.languages.registerHoverProvider(r,new qt(n)),l.languages.registerDocumentHighlightProvider(r,new Jt(n)),l.languages.registerLinkProvider(r,new sn(n)),l.languages.registerFoldingRangeProvider(r,new gn(n)),l.languages.registerDocumentSymbolProvider(r,new rn(n)),l.languages.registerSelectionRangeProvider(r,new fn(n)),l.languages.registerRenameProvider(r,new nn(n)),"html"===r&&(l.languages.registerDocumentFormattingEditProvider(r,new un(n)),l.languages.registerDocumentRangeFormattingEditProvider(r,new cn(n)))}function pn(e){const t=[],n=[],r=new Nt(e);t.push(r);const i=(...e)=>r.getLanguageServiceWorker(...e);return function(){const{languageId:t,modeConfiguration:r}=e;bn(n),r.completionItems&&n.push(l.languages.registerCompletionItemProvider(t,new mn(i))),r.hovers&&n.push(l.languages.registerHoverProvider(t,new qt(i))),r.documentHighlights&&n.push(l.languages.registerDocumentHighlightProvider(t,new Jt(i))),r.links&&n.push(l.languages.registerLinkProvider(t,new sn(i))),r.documentSymbols&&n.push(l.languages.registerDocumentSymbolProvider(t,new rn(i))),r.rename&&n.push(l.languages.registerRenameProvider(t,new nn(i))),r.foldingRanges&&n.push(l.languages.registerFoldingRangeProvider(t,new gn(i))),r.selectionRanges&&n.push(l.languages.registerSelectionRangeProvider(t,new fn(i))),r.documentFormattingEdits&&n.push(l.languages.registerDocumentFormattingEditProvider(t,new un(i))),r.documentRangeFormattingEdits&&n.push(l.languages.registerDocumentRangeFormattingEditProvider(t,new cn(i)))}(),t.push(vn(n)),vn(t)}function vn(e){return{dispose:()=>bn(e)}}function bn(e){for(;e.length;)e.pop().dispose()}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88269.9b813297.chunk.js b/ydb/core/viewer/monitoring/static/js/88269.9b813297.chunk.js new file mode 100644 index 000000000000..14a8fa4f8355 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88269.9b813297.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88269],{16238:e=>{function a(e){e.languages.elm={comment:/--.*|\{-[\s\S]*?-\}/,char:{pattern:/'(?:[^\\'\r\n]|\\(?:[abfnrtv\\']|\d+|x[0-9a-fA-F]+|u\{[0-9a-fA-F]+\}))'/,greedy:!0},string:[{pattern:/"""[\s\S]*?"""/,greedy:!0},{pattern:/"(?:[^\\"\r\n]|\\.)*"/,greedy:!0}],"import-statement":{pattern:/(^[\t ]*)import\s+[A-Z]\w*(?:\.[A-Z]\w*)*(?:\s+as\s+(?:[A-Z]\w*)(?:\.[A-Z]\w*)*)?(?:\s+exposing\s+)?/m,lookbehind:!0,inside:{keyword:/\b(?:as|exposing|import)\b/}},keyword:/\b(?:alias|as|case|else|exposing|if|in|infixl|infixr|let|module|of|then|type)\b/,builtin:/\b(?:abs|acos|always|asin|atan|atan2|ceiling|clamp|compare|cos|curry|degrees|e|flip|floor|fromPolar|identity|isInfinite|isNaN|logBase|max|min|negate|never|not|pi|radians|rem|round|sin|sqrt|tan|toFloat|toPolar|toString|truncate|turns|uncurry|xor)\b/,number:/\b(?:\d+(?:\.\d+)?(?:e[+-]?\d+)?|0x[0-9a-f]+)\b/i,operator:/\s\.\s|[+\-/*=.$<>:&|^?%#@~!]{2,}|[+\-/*=$<>:&|^?%#@~!]/,hvariable:/\b(?:[A-Z]\w*\.)*[a-z]\w*\b/,constant:/\b(?:[A-Z]\w*\.)*[A-Z]\w*\b/,punctuation:/[{}[\]|(),.:]/}}e.exports=a,a.displayName="elm",a.aliases=[]},88269:(e,a,n)=>{n.d(a,{default:()=>s});var t=n(16238);const s=n.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8840.5eb376ca.chunk.js b/ydb/core/viewer/monitoring/static/js/8840.5eb376ca.chunk.js deleted file mode 100644 index 4dca742532e6..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8840.5eb376ca.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8840],{58840:function(e,a,t){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=a(e),r={words:{m:["jedan minut","jednog minuta"],mm:["%d minut","%d minuta","%d minuta"],h:["jedan sat","jednog sata"],hh:["%d sat","%d sata","%d sati"],d:["jedan dan","jednog dana"],dd:["%d dan","%d dana","%d dana"],M:["jedan mesec","jednog meseca"],MM:["%d mesec","%d meseca","%d meseci"],y:["jednu godinu","jedne godine"],yy:["%d godinu","%d godine","%d godina"]},correctGrammarCase:function(e,a){return e%10>=1&&e%10<=4&&(e%100<10||e%100>=20)?e%10==1?a[0]:a[1]:a[2]},relativeTimeFormatter:function(e,a,t,d){var n=r.words[t];if(1===t.length)return"y"===t&&a?"jedna godina":d||a?n[0]:n[1];var i=r.correctGrammarCase(e,n);return"yy"===t&&a&&"%d godinu"===i?e+" godina":i.replace("%d",e)}},d={name:"sr",weekdays:"Nedelja_Ponedeljak_Utorak_Sreda_\u010cetvrtak_Petak_Subota".split("_"),weekdaysShort:"Ned._Pon._Uto._Sre._\u010cet._Pet._Sub.".split("_"),weekdaysMin:"ne_po_ut_sr_\u010de_pe_su".split("_"),months:"Januar_Februar_Mart_April_Maj_Jun_Jul_Avgust_Septembar_Oktobar_Novembar_Decembar".split("_"),monthsShort:"Jan._Feb._Mar._Apr._Maj_Jun_Jul_Avg._Sep._Okt._Nov._Dec.".split("_"),weekStart:1,relativeTime:{future:"za %s",past:"pre %s",s:"nekoliko sekundi",m:r.relativeTimeFormatter,mm:r.relativeTimeFormatter,h:r.relativeTimeFormatter,hh:r.relativeTimeFormatter,d:r.relativeTimeFormatter,dd:r.relativeTimeFormatter,M:r.relativeTimeFormatter,MM:r.relativeTimeFormatter,y:r.relativeTimeFormatter,yy:r.relativeTimeFormatter},ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"D. M. YYYY.",LL:"D. MMMM YYYY.",LLL:"D. MMMM YYYY. H:mm",LLLL:"dddd, D. MMMM YYYY. H:mm"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88432.95ced9fa.chunk.js b/ydb/core/viewer/monitoring/static/js/88432.95ced9fa.chunk.js new file mode 100644 index 000000000000..0eb6f7472d69 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88432.95ced9fa.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88432],{60723:e=>{function o(e){e.languages["go-mod"]=e.languages["go-module"]={comment:{pattern:/\/\/.*/,greedy:!0},version:{pattern:/(^|[\s()[\],])v\d+\.\d+\.\d+(?:[+-][-+.\w]*)?(?![^\s()[\],])/,lookbehind:!0,alias:"number"},"go-version":{pattern:/((?:^|\s)go\s+)\d+(?:\.\d+){1,2}/,lookbehind:!0,alias:"number"},keyword:{pattern:/^([ \t]*)(?:exclude|go|module|replace|require|retract)\b/m,lookbehind:!0},operator:/=>/,punctuation:/[()[\],]/}}e.exports=o,o.displayName="goModule",o.aliases=[]},88432:(e,o,a)=>{a.d(o,{default:()=>n});var d=a(60723);const n=a.n(d)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8868.a9031705.chunk.js b/ydb/core/viewer/monitoring/static/js/8868.a9031705.chunk.js deleted file mode 100644 index 97e1696a3ee4..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8868.a9031705.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8868],{28868:(e,b,d)=>{d.r(b)}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88706.b895fbe4.chunk.js b/ydb/core/viewer/monitoring/static/js/88706.b895fbe4.chunk.js new file mode 100644 index 000000000000..ebb51cbe571d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88706.b895fbe4.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88706],{88706:function(Y,M,_){Y.exports=function(Y){"use strict";function M(Y){return Y&&"object"==typeof Y&&"default"in Y?Y:{default:Y}}var _=M(Y),d={s:"\u05de\u05e1\u05e4\u05e8 \u05e9\u05e0\u05d9\u05d5\u05ea",ss:"%d \u05e9\u05e0\u05d9\u05d5\u05ea",m:"\u05d3\u05e7\u05d4",mm:"%d \u05d3\u05e7\u05d5\u05ea",h:"\u05e9\u05e2\u05d4",hh:"%d \u05e9\u05e2\u05d5\u05ea",hh2:"\u05e9\u05e2\u05ea\u05d9\u05d9\u05dd",d:"\u05d9\u05d5\u05dd",dd:"%d \u05d9\u05de\u05d9\u05dd",dd2:"\u05d9\u05d5\u05de\u05d9\u05d9\u05dd",M:"\u05d7\u05d5\u05d3\u05e9",MM:"%d \u05d7\u05d5\u05d3\u05e9\u05d9\u05dd",MM2:"\u05d7\u05d5\u05d3\u05e9\u05d9\u05d9\u05dd",y:"\u05e9\u05e0\u05d4",yy:"%d \u05e9\u05e0\u05d9\u05dd",yy2:"\u05e9\u05e0\u05ea\u05d9\u05d9\u05dd"};function l(Y,M,_){return(d[_+(2===Y?"2":"")]||d[_]).replace("%d",Y)}var m={name:"he",weekdays:"\u05e8\u05d0\u05e9\u05d5\u05df_\u05e9\u05e0\u05d9_\u05e9\u05dc\u05d9\u05e9\u05d9_\u05e8\u05d1\u05d9\u05e2\u05d9_\u05d7\u05de\u05d9\u05e9\u05d9_\u05e9\u05d9\u05e9\u05d9_\u05e9\u05d1\u05ea".split("_"),weekdaysShort:"\u05d0\u05f3_\u05d1\u05f3_\u05d2\u05f3_\u05d3\u05f3_\u05d4\u05f3_\u05d5\u05f3_\u05e9\u05f3".split("_"),weekdaysMin:"\u05d0\u05f3_\u05d1\u05f3_\u05d2\u05f3_\u05d3\u05f3_\u05d4\u05f3_\u05d5_\u05e9\u05f3".split("_"),months:"\u05d9\u05e0\u05d5\u05d0\u05e8_\u05e4\u05d1\u05e8\u05d5\u05d0\u05e8_\u05de\u05e8\u05e5_\u05d0\u05e4\u05e8\u05d9\u05dc_\u05de\u05d0\u05d9_\u05d9\u05d5\u05e0\u05d9_\u05d9\u05d5\u05dc\u05d9_\u05d0\u05d5\u05d2\u05d5\u05e1\u05d8_\u05e1\u05e4\u05d8\u05de\u05d1\u05e8_\u05d0\u05d5\u05e7\u05d8\u05d5\u05d1\u05e8_\u05e0\u05d5\u05d1\u05de\u05d1\u05e8_\u05d3\u05e6\u05de\u05d1\u05e8".split("_"),monthsShort:"\u05d9\u05e0\u05d5_\u05e4\u05d1\u05e8_\u05de\u05e8\u05e5_\u05d0\u05e4\u05e8_\u05de\u05d0\u05d9_\u05d9\u05d5\u05e0_\u05d9\u05d5\u05dc_\u05d0\u05d5\u05d2_\u05e1\u05e4\u05d8_\u05d0\u05d5\u05e7_\u05e0\u05d5\u05d1_\u05d3\u05e6\u05de".split("_"),relativeTime:{future:"\u05d1\u05e2\u05d5\u05d3 %s",past:"\u05dc\u05e4\u05e0\u05d9 %s",s:l,m:l,mm:l,h:l,hh:l,d:l,dd:l,M:l,MM:l,y:l,yy:l},ordinal:function(Y){return Y},format:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D [\u05d1]MMMM YYYY",LLL:"D [\u05d1]MMMM YYYY HH:mm",LLLL:"dddd, D [\u05d1]MMMM YYYY HH:mm",l:"D/M/YYYY",ll:"D MMM YYYY",lll:"D MMM YYYY HH:mm",llll:"ddd, D MMM YYYY HH:mm"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D [\u05d1]MMMM YYYY",LLL:"D [\u05d1]MMMM YYYY HH:mm",LLLL:"dddd, D [\u05d1]MMMM YYYY HH:mm",l:"D/M/YYYY",ll:"D MMM YYYY",lll:"D MMM YYYY HH:mm",llll:"ddd, D MMM YYYY HH:mm"}};return _.default.locale(m,null,!0),m}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88810.cb646554.chunk.js b/ydb/core/viewer/monitoring/static/js/88810.cb646554.chunk.js new file mode 100644 index 000000000000..b0b1ddabb118 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88810.cb646554.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88810],{88810:(e,s,t)=>{t.d(s,{default:()=>a});var n=t(96087);const a=t.n(n)()},96087:e=>{function s(e){!function(e){function s(e,t){return t<=0?/[]/.source:e.replace(//g,(function(){return s(e,t-1)}))}var t=/'[{}:=,](?:[^']|'')*'(?!')/,n={pattern:/''/,greedy:!0,alias:"operator"},a={pattern:t,greedy:!0,inside:{escape:n}},r=s(/\{(?:[^{}']|'(?![{},'])|''||)*\}/.source.replace(//g,(function(){return t.source})),8),i={pattern:RegExp(r),inside:{message:{pattern:/^(\{)[\s\S]+(?=\}$)/,lookbehind:!0,inside:null},"message-delimiter":{pattern:/./,alias:"punctuation"}}};e.languages["icu-message-format"]={argument:{pattern:RegExp(r),greedy:!0,inside:{content:{pattern:/^(\{)[\s\S]+(?=\}$)/,lookbehind:!0,inside:{"argument-name":{pattern:/^(\s*)[^{}:=,\s]+/,lookbehind:!0},"choice-style":{pattern:/^(\s*,\s*choice\s*,\s*)\S(?:[\s\S]*\S)?/,lookbehind:!0,inside:{punctuation:/\|/,range:{pattern:/^(\s*)[+-]?(?:\d+(?:\.\d*)?|\u221e)\s*[<#\u2264]/,lookbehind:!0,inside:{operator:/[<#\u2264]/,number:/\S+/}},rest:null}},"plural-style":{pattern:/^(\s*,\s*(?:plural|selectordinal)\s*,\s*)\S(?:[\s\S]*\S)?/,lookbehind:!0,inside:{offset:/^offset:\s*\d+/,"nested-message":i,selector:{pattern:/=\d+|[^{}:=,\s]+/,inside:{keyword:/^(?:few|many|one|other|two|zero)$/}}}},"select-style":{pattern:/^(\s*,\s*select\s*,\s*)\S(?:[\s\S]*\S)?/,lookbehind:!0,inside:{"nested-message":i,selector:{pattern:/[^{}:=,\s]+/,inside:{keyword:/^other$/}}}},keyword:/\b(?:choice|plural|select|selectordinal)\b/,"arg-type":{pattern:/\b(?:date|duration|number|ordinal|spellout|time)\b/,alias:"keyword"},"arg-skeleton":{pattern:/(,\s*)::[^{}:=,\s]+/,lookbehind:!0},"arg-style":{pattern:/(,\s*)(?:currency|full|integer|long|medium|percent|short)(?=\s*$)/,lookbehind:!0},"arg-style-text":{pattern:RegExp(/(^\s*,\s*(?=\S))/.source+s(/(?:[^{}']|'[^']*'|\{(?:)?\})+/.source,8)+"$"),lookbehind:!0,alias:"string"},punctuation:/,/}},"argument-delimiter":{pattern:/./,alias:"operator"}}},escape:n,string:a},i.inside.message.inside=e.languages["icu-message-format"],e.languages["icu-message-format"].argument.inside.content.inside["choice-style"].inside.rest=e.languages["icu-message-format"]}(e)}e.exports=s,s.displayName="icuMessageFormat",s.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8890.9f3d8f08.chunk.js b/ydb/core/viewer/monitoring/static/js/8890.9f3d8f08.chunk.js deleted file mode 100644 index 6e00fd1b23f9..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8890.9f3d8f08.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8890],{58890:function(e,t,_){e.exports=function(e){"use strict";function t(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=t(e),n="\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a\u0648_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648_\u0623\u063a\u0633\u0637\u0633_\u0633\u0628\u062a\u0645\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0641\u0645\u0628\u0631_\u062f\u064a\u0633\u0645\u0628\u0631".split("_"),r={1:"\u0661",2:"\u0662",3:"\u0663",4:"\u0664",5:"\u0665",6:"\u0666",7:"\u0667",8:"\u0668",9:"\u0669",0:"\u0660"},d={"\u0661":"1","\u0662":"2","\u0663":"3","\u0664":"4","\u0665":"5","\u0666":"6","\u0667":"7","\u0668":"8","\u0669":"9","\u0660":"0"},u={name:"ar",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),weekdaysShort:"\u0623\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0623\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),months:n,monthsShort:n,weekStart:6,meridiem:function(e){return e>12?"\u0645":"\u0635"},relativeTime:{future:"\u0628\u0639\u062f %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0627\u0646\u064a\u0629 \u0648\u0627\u062d\u062f\u0629",m:"\u062f\u0642\u064a\u0642\u0629 \u0648\u0627\u062d\u062f\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629 \u0648\u0627\u062d\u062f\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645 \u0648\u0627\u062d\u062f",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631 \u0648\u0627\u062d\u062f",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0639\u0627\u0645 \u0648\u0627\u062d\u062f",yy:"%d \u0623\u0639\u0648\u0627\u0645"},preparse:function(e){return e.replace(/[\u0661\u0662\u0663\u0664\u0665\u0666\u0667\u0668\u0669\u0660]/g,(function(e){return d[e]})).replace(/\u060c/g,",")},postformat:function(e){return e.replace(/\d/g,(function(e){return r[e]})).replace(/,/g,"\u060c")},ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"D/\u200fM/\u200fYYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"}};return _.default.locale(u,null,!0),u}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/88987.f221b1c0.chunk.js b/ydb/core/viewer/monitoring/static/js/88987.f221b1c0.chunk.js new file mode 100644 index 000000000000..ea96abdd9695 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/88987.f221b1c0.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[88987],{24450:e=>{function n(e){e.languages.json={property:{pattern:/(^|[^\\])"(?:\\.|[^\\"\r\n])*"(?=\s*:)/,lookbehind:!0,greedy:!0},string:{pattern:/(^|[^\\])"(?:\\.|[^\\"\r\n])*"(?!\s*:)/,lookbehind:!0,greedy:!0},comment:{pattern:/\/\/.*|\/\*[\s\S]*?(?:\*\/|$)/,greedy:!0},number:/-?\b\d+(?:\.\d+)?(?:e[+-]?\d+)?\b/i,punctuation:/[{}[\],]/,operator:/:/,boolean:/\b(?:false|true)\b/,null:{pattern:/\bnull\b/,alias:"keyword"}},e.languages.webmanifest=e.languages.json}e.exports=n,n.displayName="json",n.aliases=["webmanifest"]},66248:(e,n,a)=>{var s=a(24450);function t(e){e.register(s),e.languages.jsonp=e.languages.extend("json",{punctuation:/[{}[\]();,.]/}),e.languages.insertBefore("jsonp","punctuation",{function:/(?!\s)[_$a-zA-Z\xA0-\uFFFF](?:(?!\s)[$\w\xA0-\uFFFF])*(?=\s*\()/})}e.exports=t,t.displayName="jsonp",t.aliases=[]},88987:(e,n,a)=>{a.d(n,{default:()=>t});var s=a(66248);const t=a.n(s)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/89015.1865c336.chunk.js b/ydb/core/viewer/monitoring/static/js/89015.1865c336.chunk.js new file mode 100644 index 000000000000..9abd5a645536 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/89015.1865c336.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[89015],{63266:e=>{function n(e){e.languages.wren={comment:[{pattern:/\/\*(?:[^*/]|\*(?!\/)|\/(?!\*)|\/\*(?:[^*/]|\*(?!\/)|\/(?!\*)|\/\*(?:[^*/]|\*(?!\/)|\/(?!\*))*\*\/)*\*\/)*\*\//,greedy:!0},{pattern:/(^|[^\\:])\/\/.*/,lookbehind:!0,greedy:!0}],"triple-quoted-string":{pattern:/"""[\s\S]*?"""/,greedy:!0,alias:"string"},"string-literal":null,hashbang:{pattern:/^#!\/.+/,greedy:!0,alias:"comment"},attribute:{pattern:/#!?[ \t\u3000]*\w+/,alias:"keyword"},"class-name":[{pattern:/(\bclass\s+)\w+/,lookbehind:!0},/\b[A-Z][a-z\d_]*\b/],constant:/\b[A-Z][A-Z\d_]*\b/,null:{pattern:/\bnull\b/,alias:"keyword"},keyword:/\b(?:as|break|class|construct|continue|else|for|foreign|if|import|in|is|return|static|super|this|var|while)\b/,boolean:/\b(?:false|true)\b/,number:/\b(?:0x[\da-f]+|\d+(?:\.\d+)?(?:e[+-]?\d+)?)\b/i,function:/\b[a-z_]\w*(?=\s*[({])/i,operator:/<<|>>|[=!<>]=?|&&|\|\||[-+*/%~^&|?:]|\.{2,3}/,punctuation:/[\[\](){}.,;]/},e.languages.wren["string-literal"]={pattern:/(^|[^\\"])"(?:[^\\"%]|\\[\s\S]|%(?!\()|%\((?:[^()]|\((?:[^()]|\([^)]*\))*\))*\))*"/,lookbehind:!0,greedy:!0,inside:{interpolation:{pattern:/((?:^|[^\\])(?:\\{2})*)%\((?:[^()]|\((?:[^()]|\([^)]*\))*\))*\)/,lookbehind:!0,inside:{expression:{pattern:/^(%\()[\s\S]+(?=\)$)/,lookbehind:!0,inside:e.languages.wren},"interpolation-punctuation":{pattern:/^%\(|\)$/,alias:"punctuation"}}},string:/[\s\S]+/}}}e.exports=n,n.displayName="wren",n.aliases=[]},89015:(e,n,t)=>{t.d(n,{default:()=>i});var a=t(63266);const i=t.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/89025.e20277a3.chunk.js b/ydb/core/viewer/monitoring/static/js/89025.e20277a3.chunk.js new file mode 100644 index 000000000000..3e2f0f6f9a36 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/89025.e20277a3.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[89025],{89025:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ky",weekdays:"\u0416\u0435\u043a\u0448\u0435\u043c\u0431\u0438_\u0414\u04af\u0439\u0448\u04e9\u043c\u0431\u04af_\u0428\u0435\u0439\u0448\u0435\u043c\u0431\u0438_\u0428\u0430\u0440\u0448\u0435\u043c\u0431\u0438_\u0411\u0435\u0439\u0448\u0435\u043c\u0431\u0438_\u0416\u0443\u043c\u0430_\u0418\u0448\u0435\u043c\u0431\u0438".split("_"),months:"\u044f\u043d\u0432\u0430\u0440\u044c_\u0444\u0435\u0432\u0440\u0430\u043b\u044c_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0435\u043b\u044c_\u043c\u0430\u0439_\u0438\u044e\u043d\u044c_\u0438\u044e\u043b\u044c_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043d\u0442\u044f\u0431\u0440\u044c_\u043e\u043a\u0442\u044f\u0431\u0440\u044c_\u043d\u043e\u044f\u0431\u0440\u044c_\u0434\u0435\u043a\u0430\u0431\u0440\u044c".split("_"),weekStart:1,weekdaysShort:"\u0416\u0435\u043a_\u0414\u04af\u0439_\u0428\u0435\u0439_\u0428\u0430\u0440_\u0411\u0435\u0439_\u0416\u0443\u043c_\u0418\u0448\u0435".split("_"),monthsShort:"\u044f\u043d\u0432_\u0444\u0435\u0432_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440_\u043c\u0430\u0439_\u0438\u044e\u043d\u044c_\u0438\u044e\u043b\u044c_\u0430\u0432\u0433_\u0441\u0435\u043d_\u043e\u043a\u0442_\u043d\u043e\u044f_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u0416\u043a_\u0414\u0439_\u0428\u0439_\u0428\u0440_\u0411\u0439_\u0416\u043c_\u0418\u0448".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s \u0438\u0447\u0438\u043d\u0434\u0435",past:"%s \u043c\u0443\u0440\u0443\u043d",s:"\u0431\u0438\u0440\u043d\u0435\u0447\u0435 \u0441\u0435\u043a\u0443\u043d\u0434",m:"\u0431\u0438\u0440 \u043c\u04af\u043d\u04e9\u0442",mm:"%d \u043c\u04af\u043d\u04e9\u0442",h:"\u0431\u0438\u0440 \u0441\u0430\u0430\u0442",hh:"%d \u0441\u0430\u0430\u0442",d:"\u0431\u0438\u0440 \u043a\u04af\u043d",dd:"%d \u043a\u04af\u043d",M:"\u0431\u0438\u0440 \u0430\u0439",MM:"%d \u0430\u0439",y:"\u0431\u0438\u0440 \u0436\u044b\u043b",yy:"%d \u0436\u044b\u043b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/89033.56232409.chunk.js b/ydb/core/viewer/monitoring/static/js/89033.56232409.chunk.js new file mode 100644 index 000000000000..7d6ffe506b6c --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/89033.56232409.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[89033],{11270:e=>{function a(e){e.languages.ocaml={comment:{pattern:/\(\*[\s\S]*?\*\)/,greedy:!0},char:{pattern:/'(?:[^\\\r\n']|\\(?:.|[ox]?[0-9a-f]{1,3}))'/i,greedy:!0},string:[{pattern:/"(?:\\(?:[\s\S]|\r\n)|[^\\\r\n"])*"/,greedy:!0},{pattern:/\{([a-z_]*)\|[\s\S]*?\|\1\}/,greedy:!0}],number:[/\b(?:0b[01][01_]*|0o[0-7][0-7_]*)\b/i,/\b0x[a-f0-9][a-f0-9_]*(?:\.[a-f0-9_]*)?(?:p[+-]?\d[\d_]*)?(?!\w)/i,/\b\d[\d_]*(?:\.[\d_]*)?(?:e[+-]?\d[\d_]*)?(?!\w)/i],directive:{pattern:/\B#\w+/,alias:"property"},label:{pattern:/\B~\w+/,alias:"property"},"type-variable":{pattern:/\B'\w+/,alias:"function"},variant:{pattern:/`\w+/,alias:"symbol"},keyword:/\b(?:as|assert|begin|class|constraint|do|done|downto|else|end|exception|external|for|fun|function|functor|if|in|include|inherit|initializer|lazy|let|match|method|module|mutable|new|nonrec|object|of|open|private|rec|sig|struct|then|to|try|type|val|value|virtual|when|where|while|with)\b/,boolean:/\b(?:false|true)\b/,"operator-like-punctuation":{pattern:/\[[<>|]|[>|]\]|\{<|>\}/,alias:"punctuation"},operator:/\.[.~]|:[=>]|[=<>@^|&+\-*\/$%!?~][!$%&*+\-.\/:<=>?@^|~]*|\b(?:and|asr|land|lor|lsl|lsr|lxor|mod|or)\b/,punctuation:/;;|::|[(){}\[\].,:;#]|\b_\b/}}e.exports=a,a.displayName="ocaml",a.aliases=[]},89033:(e,a,t)=>{t.d(a,{default:()=>r});var n=t(11270);const r=t.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/89222.d941dfbd.chunk.js b/ydb/core/viewer/monitoring/static/js/89222.d941dfbd.chunk.js new file mode 100644 index 000000000000..0266587504a9 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/89222.d941dfbd.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[89222],{89222:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),n={name:"af",weekdays:"Sondag_Maandag_Dinsdag_Woensdag_Donderdag_Vrydag_Saterdag".split("_"),months:"Januarie_Februarie_Maart_April_Mei_Junie_Julie_Augustus_September_Oktober_November_Desember".split("_"),weekStart:1,weekdaysShort:"Son_Maa_Din_Woe_Don_Vry_Sat".split("_"),monthsShort:"Jan_Feb_Mrt_Apr_Mei_Jun_Jul_Aug_Sep_Okt_Nov_Des".split("_"),weekdaysMin:"So_Ma_Di_Wo_Do_Vr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"oor %s",past:"%s gelede",s:"'n paar sekondes",m:"'n minuut",mm:"%d minute",h:"'n uur",hh:"%d ure",d:"'n dag",dd:"%d dae",M:"'n maand",MM:"%d maande",y:"'n jaar",yy:"%d jaar"}};return _.default.locale(n,null,!0),n}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/89697.31847e00.chunk.js b/ydb/core/viewer/monitoring/static/js/89697.31847e00.chunk.js new file mode 100644 index 000000000000..be75639bb7dc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/89697.31847e00.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[89697],{89697:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-ma",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648\u0632_\u063a\u0634\u062a_\u0634\u062a\u0646\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0646\u0628\u0631_\u062f\u062c\u0646\u0628\u0631".split("_"),weekStart:6,weekdaysShort:"\u0627\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648\u0632_\u063a\u0634\u062a_\u0634\u062a\u0646\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0646\u0628\u0631_\u062f\u062c\u0646\u0628\u0631".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8979.0c0acc31.chunk.js b/ydb/core/viewer/monitoring/static/js/8979.0c0acc31.chunk.js deleted file mode 100644 index 52d875ad6cc5..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8979.0c0acc31.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8979],{78979:(e,t,i)=>{i.r(t),i.d(t,{Adapter:()=>f,CodeActionAdaptor:()=>M,DefinitionAdapter:()=>C,DiagnosticsAdapter:()=>_,DocumentHighlightAdapter:()=>v,FormatAdapter:()=>O,FormatHelper:()=>L,FormatOnTypeAdapter:()=>N,InlayHintsAdapter:()=>R,Kind:()=>F,LibFiles:()=>y,OutlineAdapter:()=>A,QuickInfoAdapter:()=>k,ReferenceAdapter:()=>D,RenameAdapter:()=>K,SignatureHelpAdapter:()=>x,SuggestAdapter:()=>w,WorkerManager:()=>p,flattenDiagnosticMessageText:()=>h,getJavaScriptWorker:()=>V,getTypeScriptWorker:()=>j,setupJavaScript:()=>H,setupTypeScript:()=>E});var s,r,n=i(80781),a=i(24152),o=Object.defineProperty,l=Object.getOwnPropertyDescriptor,c=Object.getOwnPropertyNames,d=Object.prototype.hasOwnProperty,u=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let r of c(t))d.call(e,r)||r===i||o(e,r,{get:()=>t[r],enumerable:!(s=l(t,r))||s.enumerable});return e},g={};u(g,s=n,"default"),r&&u(r,s,"default");var p=class{constructor(e,t){this._modeId=e,this._defaults=t,this._worker=null,this._client=null,this._configChangeListener=this._defaults.onDidChange((()=>this._stopWorker())),this._updateExtraLibsToken=0,this._extraLibsChangeListener=this._defaults.onDidExtraLibsChange((()=>this._updateExtraLibs()))}dispose(){this._configChangeListener.dispose(),this._extraLibsChangeListener.dispose(),this._stopWorker()}_stopWorker(){this._worker&&(this._worker.dispose(),this._worker=null),this._client=null}async _updateExtraLibs(){if(!this._worker)return;const e=++this._updateExtraLibsToken,t=await this._worker.getProxy();this._updateExtraLibsToken===e&&t.updateExtraLibs(this._defaults.getExtraLibs())}_getClient(){return this._client||(this._client=(async()=>(this._worker=g.editor.createWebWorker({moduleId:"vs/language/typescript/tsWorker",label:this._modeId,keepIdleModels:!0,createData:{compilerOptions:this._defaults.getCompilerOptions(),extraLibs:this._defaults.getExtraLibs(),customWorkerPath:this._defaults.workerOptions.customWorkerPath,inlayHintsOptions:this._defaults.inlayHintsOptions}}),this._defaults.getEagerModelSync()?await this._worker.withSyncedResources(g.editor.getModels().filter((e=>e.getLanguageId()===this._modeId)).map((e=>e.uri))):await this._worker.getProxy()))()),this._client}async getLanguageServiceWorker(...e){const t=await this._getClient();return this._worker&&await this._worker.withSyncedResources(e),t}},m={};function h(e,t,i=0){if("string"===typeof e)return e;if(void 0===e)return"";let s="";if(i){s+=t;for(let e=0;ee.text)).join(""):""}m["lib.d.ts"]=!0,m["lib.decorators.d.ts"]=!0,m["lib.decorators.legacy.d.ts"]=!0,m["lib.dom.asynciterable.d.ts"]=!0,m["lib.dom.d.ts"]=!0,m["lib.dom.iterable.d.ts"]=!0,m["lib.es2015.collection.d.ts"]=!0,m["lib.es2015.core.d.ts"]=!0,m["lib.es2015.d.ts"]=!0,m["lib.es2015.generator.d.ts"]=!0,m["lib.es2015.iterable.d.ts"]=!0,m["lib.es2015.promise.d.ts"]=!0,m["lib.es2015.proxy.d.ts"]=!0,m["lib.es2015.reflect.d.ts"]=!0,m["lib.es2015.symbol.d.ts"]=!0,m["lib.es2015.symbol.wellknown.d.ts"]=!0,m["lib.es2016.array.include.d.ts"]=!0,m["lib.es2016.d.ts"]=!0,m["lib.es2016.full.d.ts"]=!0,m["lib.es2016.intl.d.ts"]=!0,m["lib.es2017.d.ts"]=!0,m["lib.es2017.date.d.ts"]=!0,m["lib.es2017.full.d.ts"]=!0,m["lib.es2017.intl.d.ts"]=!0,m["lib.es2017.object.d.ts"]=!0,m["lib.es2017.sharedmemory.d.ts"]=!0,m["lib.es2017.string.d.ts"]=!0,m["lib.es2017.typedarrays.d.ts"]=!0,m["lib.es2018.asyncgenerator.d.ts"]=!0,m["lib.es2018.asynciterable.d.ts"]=!0,m["lib.es2018.d.ts"]=!0,m["lib.es2018.full.d.ts"]=!0,m["lib.es2018.intl.d.ts"]=!0,m["lib.es2018.promise.d.ts"]=!0,m["lib.es2018.regexp.d.ts"]=!0,m["lib.es2019.array.d.ts"]=!0,m["lib.es2019.d.ts"]=!0,m["lib.es2019.full.d.ts"]=!0,m["lib.es2019.intl.d.ts"]=!0,m["lib.es2019.object.d.ts"]=!0,m["lib.es2019.string.d.ts"]=!0,m["lib.es2019.symbol.d.ts"]=!0,m["lib.es2020.bigint.d.ts"]=!0,m["lib.es2020.d.ts"]=!0,m["lib.es2020.date.d.ts"]=!0,m["lib.es2020.full.d.ts"]=!0,m["lib.es2020.intl.d.ts"]=!0,m["lib.es2020.number.d.ts"]=!0,m["lib.es2020.promise.d.ts"]=!0,m["lib.es2020.sharedmemory.d.ts"]=!0,m["lib.es2020.string.d.ts"]=!0,m["lib.es2020.symbol.wellknown.d.ts"]=!0,m["lib.es2021.d.ts"]=!0,m["lib.es2021.full.d.ts"]=!0,m["lib.es2021.intl.d.ts"]=!0,m["lib.es2021.promise.d.ts"]=!0,m["lib.es2021.string.d.ts"]=!0,m["lib.es2021.weakref.d.ts"]=!0,m["lib.es2022.array.d.ts"]=!0,m["lib.es2022.d.ts"]=!0,m["lib.es2022.error.d.ts"]=!0,m["lib.es2022.full.d.ts"]=!0,m["lib.es2022.intl.d.ts"]=!0,m["lib.es2022.object.d.ts"]=!0,m["lib.es2022.regexp.d.ts"]=!0,m["lib.es2022.sharedmemory.d.ts"]=!0,m["lib.es2022.string.d.ts"]=!0,m["lib.es2023.array.d.ts"]=!0,m["lib.es2023.collection.d.ts"]=!0,m["lib.es2023.d.ts"]=!0,m["lib.es2023.full.d.ts"]=!0,m["lib.es5.d.ts"]=!0,m["lib.es6.d.ts"]=!0,m["lib.esnext.collection.d.ts"]=!0,m["lib.esnext.d.ts"]=!0,m["lib.esnext.decorators.d.ts"]=!0,m["lib.esnext.disposable.d.ts"]=!0,m["lib.esnext.full.d.ts"]=!0,m["lib.esnext.intl.d.ts"]=!0,m["lib.esnext.object.d.ts"]=!0,m["lib.esnext.promise.d.ts"]=!0,m["lib.scripthost.d.ts"]=!0,m["lib.webworker.asynciterable.d.ts"]=!0,m["lib.webworker.d.ts"]=!0,m["lib.webworker.importscripts.d.ts"]=!0,m["lib.webworker.iterable.d.ts"]=!0;var f=class{constructor(e){this._worker=e}_textSpanToRange(e,t){let i=e.getPositionAt(t.start),s=e.getPositionAt(t.start+t.length),{lineNumber:r,column:n}=i,{lineNumber:a,column:o}=s;return{startLineNumber:r,startColumn:n,endLineNumber:a,endColumn:o}}},y=class{constructor(e){this._worker=e,this._libFiles={},this._hasFetchedLibFiles=!1,this._fetchLibFilesPromise=null}isLibFile(e){return!!e&&(0===e.path.indexOf("/lib.")&&!!m[e.path.slice(1)])}getOrCreateModel(e){const t=g.Uri.parse(e),i=g.editor.getModel(t);if(i)return i;if(this.isLibFile(t)&&this._hasFetchedLibFiles)return g.editor.createModel(this._libFiles[t.path.slice(1)],"typescript",t);const s=a.IF.getExtraLibs()[e];return s?g.editor.createModel(s.content,"typescript",t):null}_containsLibFile(e){for(let t of e)if(this.isLibFile(t))return!0;return!1}async fetchLibFilesIfNecessary(e){this._containsLibFile(e)&&await this._fetchLibFiles()}_fetchLibFiles(){return this._fetchLibFilesPromise||(this._fetchLibFilesPromise=this._worker().then((e=>e.getLibFiles())).then((e=>{this._hasFetchedLibFiles=!0,this._libFiles=e}))),this._fetchLibFilesPromise}},_=class extends f{constructor(e,t,i,s){super(s),this._libFiles=e,this._defaults=t,this._selector=i,this._disposables=[],this._listener=Object.create(null);const r=e=>{if(e.getLanguageId()!==i)return;const t=()=>{const{onlyVisible:t}=this._defaults.getDiagnosticsOptions();t?e.isAttachedToEditor()&&this._doValidate(e):this._doValidate(e)};let s;const r=e.onDidChangeContent((()=>{clearTimeout(s),s=window.setTimeout(t,500)})),n=e.onDidChangeAttached((()=>{const{onlyVisible:i}=this._defaults.getDiagnosticsOptions();i&&(e.isAttachedToEditor()?t():g.editor.setModelMarkers(e,this._selector,[]))}));this._listener[e.uri.toString()]={dispose(){r.dispose(),n.dispose(),clearTimeout(s)}},t()},n=e=>{g.editor.setModelMarkers(e,this._selector,[]);const t=e.uri.toString();this._listener[t]&&(this._listener[t].dispose(),delete this._listener[t])};this._disposables.push(g.editor.onDidCreateModel((e=>r(e)))),this._disposables.push(g.editor.onWillDisposeModel(n)),this._disposables.push(g.editor.onDidChangeModelLanguage((e=>{n(e.model),r(e.model)}))),this._disposables.push({dispose(){for(const e of g.editor.getModels())n(e)}});const a=()=>{for(const e of g.editor.getModels())n(e),r(e)};this._disposables.push(this._defaults.onDidChange(a)),this._disposables.push(this._defaults.onDidExtraLibsChange(a)),g.editor.getModels().forEach((e=>r(e)))}dispose(){this._disposables.forEach((e=>e&&e.dispose())),this._disposables=[]}async _doValidate(e){const t=await this._worker(e.uri);if(e.isDisposed())return;const i=[],{noSyntaxValidation:s,noSemanticValidation:r,noSuggestionDiagnostics:n}=this._defaults.getDiagnosticsOptions();s||i.push(t.getSyntacticDiagnostics(e.uri.toString())),r||i.push(t.getSemanticDiagnostics(e.uri.toString())),n||i.push(t.getSuggestionDiagnostics(e.uri.toString()));const a=await Promise.all(i);if(!a||e.isDisposed())return;const o=a.reduce(((e,t)=>t.concat(e)),[]).filter((e=>-1===(this._defaults.getDiagnosticsOptions().diagnosticCodesToIgnore||[]).indexOf(e.code))),l=o.map((e=>e.relatedInformation||[])).reduce(((e,t)=>t.concat(e)),[]).map((e=>e.file?g.Uri.parse(e.file.fileName):null));await this._libFiles.fetchLibFilesIfNecessary(l),e.isDisposed()||g.editor.setModelMarkers(e,this._selector,o.map((t=>this._convertDiagnostics(e,t))))}_convertDiagnostics(e,t){const i=t.start||0,s=t.length||1,{lineNumber:r,column:n}=e.getPositionAt(i),{lineNumber:a,column:o}=e.getPositionAt(i+s),l=[];return t.reportsUnnecessary&&l.push(g.MarkerTag.Unnecessary),t.reportsDeprecated&&l.push(g.MarkerTag.Deprecated),{severity:this._tsDiagnosticCategoryToMarkerSeverity(t.category),startLineNumber:r,startColumn:n,endLineNumber:a,endColumn:o,message:h(t.messageText,"\n"),code:t.code.toString(),tags:l,relatedInformation:this._convertRelatedInformation(e,t.relatedInformation)}}_convertRelatedInformation(e,t){if(!t)return[];const i=[];return t.forEach((t=>{let s=e;if(t.file&&(s=this._libFiles.getOrCreateModel(t.file.fileName)),!s)return;const r=t.start||0,n=t.length||1,{lineNumber:a,column:o}=s.getPositionAt(r),{lineNumber:l,column:c}=s.getPositionAt(r+n);i.push({resource:s.uri,startLineNumber:a,startColumn:o,endLineNumber:l,endColumn:c,message:h(t.messageText,"\n")})})),i}_tsDiagnosticCategoryToMarkerSeverity(e){switch(e){case 1:return g.MarkerSeverity.Error;case 3:return g.MarkerSeverity.Info;case 0:return g.MarkerSeverity.Warning;case 2:return g.MarkerSeverity.Hint}return g.MarkerSeverity.Info}},w=class e extends f{get triggerCharacters(){return["."]}async provideCompletionItems(t,i,s,r){const n=t.getWordUntilPosition(i),a=new g.Range(i.lineNumber,n.startColumn,i.lineNumber,n.endColumn),o=t.uri,l=t.getOffsetAt(i),c=await this._worker(o);if(t.isDisposed())return;const d=await c.getCompletionsAtPosition(o.toString(),l);if(!d||t.isDisposed())return;return{suggestions:d.entries.map((s=>{let r=a;if(s.replacementSpan){const e=t.getPositionAt(s.replacementSpan.start),i=t.getPositionAt(s.replacementSpan.start+s.replacementSpan.length);r=new g.Range(e.lineNumber,e.column,i.lineNumber,i.column)}const n=[];return void 0!==s.kindModifiers&&-1!==s.kindModifiers.indexOf("deprecated")&&n.push(g.languages.CompletionItemTag.Deprecated),{uri:o,position:i,offset:l,range:r,label:s.name,insertText:s.name,sortText:s.sortText,kind:e.convertKind(s.kind),tags:n}}))}}async resolveCompletionItem(t,i){const s=t,r=s.uri,n=s.position,a=s.offset,o=await this._worker(r),l=await o.getCompletionEntryDetails(r.toString(),a,s.label);return l?{uri:r,position:n,label:l.name,kind:e.convertKind(l.kind),detail:b(l.displayParts),documentation:{value:e.createDocumentationString(l)}}:s}static convertKind(e){switch(e){case F.primitiveType:case F.keyword:return g.languages.CompletionItemKind.Keyword;case F.variable:case F.localVariable:return g.languages.CompletionItemKind.Variable;case F.memberVariable:case F.memberGetAccessor:case F.memberSetAccessor:return g.languages.CompletionItemKind.Field;case F.function:case F.memberFunction:case F.constructSignature:case F.callSignature:case F.indexSignature:return g.languages.CompletionItemKind.Function;case F.enum:return g.languages.CompletionItemKind.Enum;case F.module:return g.languages.CompletionItemKind.Module;case F.class:return g.languages.CompletionItemKind.Class;case F.interface:return g.languages.CompletionItemKind.Interface;case F.warning:return g.languages.CompletionItemKind.File}return g.languages.CompletionItemKind.Property}static createDocumentationString(e){let t=b(e.documentation);if(e.tags)for(const i of e.tags)t+=`\n\n${S(i)}`;return t}};function S(e){let t=`*@${e.name}*`;if("param"===e.name&&e.text){const[i,...s]=e.text;t+=`\`${i.text}\``,s.length>0&&(t+=` \u2014 ${s.map((e=>e.text)).join(" ")}`)}else Array.isArray(e.text)?t+=` \u2014 ${e.text.map((e=>e.text)).join(" ")}`:e.text&&(t+=` \u2014 ${e.text}`);return t}var x=class e extends f{constructor(){super(...arguments),this.signatureHelpTriggerCharacters=["(",","]}static _toSignatureHelpTriggerReason(e){switch(e.triggerKind){case g.languages.SignatureHelpTriggerKind.TriggerCharacter:return e.triggerCharacter?e.isRetrigger?{kind:"retrigger",triggerCharacter:e.triggerCharacter}:{kind:"characterTyped",triggerCharacter:e.triggerCharacter}:{kind:"invoked"};case g.languages.SignatureHelpTriggerKind.ContentChange:return e.isRetrigger?{kind:"retrigger"}:{kind:"invoked"};case g.languages.SignatureHelpTriggerKind.Invoke:default:return{kind:"invoked"}}}async provideSignatureHelp(t,i,s,r){const n=t.uri,a=t.getOffsetAt(i),o=await this._worker(n);if(t.isDisposed())return;const l=await o.getSignatureHelpItems(n.toString(),a,{triggerReason:e._toSignatureHelpTriggerReason(r)});if(!l||t.isDisposed())return;const c={activeSignature:l.selectedItemIndex,activeParameter:l.argumentIndex,signatures:[]};return l.items.forEach((e=>{const t={label:"",parameters:[]};t.documentation={value:b(e.documentation)},t.label+=b(e.prefixDisplayParts),e.parameters.forEach(((i,s,r)=>{const n=b(i.displayParts),a={label:n,documentation:{value:b(i.documentation)}};t.label+=n,t.parameters.push(a),sS(e))).join(" \n\n"):"",c=b(a.displayParts);return{range:this._textSpanToRange(e,a.textSpan),contents:[{value:"```typescript\n"+c+"\n```\n"},{value:o+(l?"\n\n"+l:"")}]}}},v=class extends f{async provideDocumentHighlights(e,t,i){const s=e.uri,r=e.getOffsetAt(t),n=await this._worker(s);if(e.isDisposed())return;const a=await n.getDocumentHighlights(s.toString(),r,[s.toString()]);return a&&!e.isDisposed()?a.flatMap((t=>t.highlightSpans.map((t=>({range:this._textSpanToRange(e,t.textSpan),kind:"writtenReference"===t.kind?g.languages.DocumentHighlightKind.Write:g.languages.DocumentHighlightKind.Text}))))):void 0}},C=class extends f{constructor(e,t){super(t),this._libFiles=e}async provideDefinition(e,t,i){const s=e.uri,r=e.getOffsetAt(t),n=await this._worker(s);if(e.isDisposed())return;const a=await n.getDefinitionAtPosition(s.toString(),r);if(!a||e.isDisposed())return;if(await this._libFiles.fetchLibFilesIfNecessary(a.map((e=>g.Uri.parse(e.fileName)))),e.isDisposed())return;const o=[];for(let l of a){const e=this._libFiles.getOrCreateModel(l.fileName);e&&o.push({uri:e.uri,range:this._textSpanToRange(e,l.textSpan)})}return o}},D=class extends f{constructor(e,t){super(t),this._libFiles=e}async provideReferences(e,t,i,s){const r=e.uri,n=e.getOffsetAt(t),a=await this._worker(r);if(e.isDisposed())return;const o=await a.getReferencesAtPosition(r.toString(),n);if(!o||e.isDisposed())return;if(await this._libFiles.fetchLibFilesIfNecessary(o.map((e=>g.Uri.parse(e.fileName)))),e.isDisposed())return;const l=[];for(let c of o){const e=this._libFiles.getOrCreateModel(c.fileName);e&&l.push({uri:e.uri,range:this._textSpanToRange(e,c.textSpan)})}return l}},A=class extends f{async provideDocumentSymbols(e,t){const i=e.uri,s=await this._worker(i);if(e.isDisposed())return;const r=await s.getNavigationTree(i.toString());if(!r||e.isDisposed())return;const n=(t,i)=>({name:t.text,detail:"",kind:I[t.kind]||g.languages.SymbolKind.Variable,range:this._textSpanToRange(e,t.spans[0]),selectionRange:this._textSpanToRange(e,t.spans[0]),tags:[],children:t.childItems?.map((e=>n(e,t.text))),containerName:i});return r.childItems?r.childItems.map((e=>n(e))):[]}},F=class{static{this.unknown=""}static{this.keyword="keyword"}static{this.script="script"}static{this.module="module"}static{this.class="class"}static{this.interface="interface"}static{this.type="type"}static{this.enum="enum"}static{this.variable="var"}static{this.localVariable="local var"}static{this.function="function"}static{this.localFunction="local function"}static{this.memberFunction="method"}static{this.memberGetAccessor="getter"}static{this.memberSetAccessor="setter"}static{this.memberVariable="property"}static{this.constructorImplementation="constructor"}static{this.callSignature="call"}static{this.indexSignature="index"}static{this.constructSignature="construct"}static{this.parameter="parameter"}static{this.typeParameter="type parameter"}static{this.primitiveType="primitive type"}static{this.label="label"}static{this.alias="alias"}static{this.const="const"}static{this.let="let"}static{this.warning="warning"}},I=Object.create(null);I[F.module]=g.languages.SymbolKind.Module,I[F.class]=g.languages.SymbolKind.Class,I[F.enum]=g.languages.SymbolKind.Enum,I[F.interface]=g.languages.SymbolKind.Interface,I[F.memberFunction]=g.languages.SymbolKind.Method,I[F.memberVariable]=g.languages.SymbolKind.Property,I[F.memberGetAccessor]=g.languages.SymbolKind.Property,I[F.memberSetAccessor]=g.languages.SymbolKind.Property,I[F.variable]=g.languages.SymbolKind.Variable,I[F.const]=g.languages.SymbolKind.Variable,I[F.localVariable]=g.languages.SymbolKind.Variable,I[F.variable]=g.languages.SymbolKind.Variable,I[F.function]=g.languages.SymbolKind.Function,I[F.localFunction]=g.languages.SymbolKind.Function;var T,P,L=class extends f{static _convertOptions(e){return{ConvertTabsToSpaces:e.insertSpaces,TabSize:e.tabSize,IndentSize:e.tabSize,IndentStyle:2,NewLineCharacter:"\n",InsertSpaceAfterCommaDelimiter:!0,InsertSpaceAfterSemicolonInForStatements:!0,InsertSpaceBeforeAndAfterBinaryOperators:!0,InsertSpaceAfterKeywordsInControlFlowStatements:!0,InsertSpaceAfterFunctionKeywordForAnonymousFunctions:!0,InsertSpaceAfterOpeningAndBeforeClosingNonemptyParenthesis:!1,InsertSpaceAfterOpeningAndBeforeClosingNonemptyBrackets:!1,InsertSpaceAfterOpeningAndBeforeClosingTemplateStringBraces:!1,PlaceOpenBraceOnNewLineForControlBlocks:!1,PlaceOpenBraceOnNewLineForFunctions:!1}}_convertTextChanges(e,t){return{text:t.newText,range:this._textSpanToRange(e,t.span)}}},O=class extends L{constructor(){super(...arguments),this.canFormatMultipleRanges=!1}async provideDocumentRangeFormattingEdits(e,t,i,s){const r=e.uri,n=e.getOffsetAt({lineNumber:t.startLineNumber,column:t.startColumn}),a=e.getOffsetAt({lineNumber:t.endLineNumber,column:t.endColumn}),o=await this._worker(r);if(e.isDisposed())return;const l=await o.getFormattingEditsForRange(r.toString(),n,a,L._convertOptions(i));return l&&!e.isDisposed()?l.map((t=>this._convertTextChanges(e,t))):void 0}},N=class extends L{get autoFormatTriggerCharacters(){return[";","}","\n"]}async provideOnTypeFormattingEdits(e,t,i,s,r){const n=e.uri,a=e.getOffsetAt(t),o=await this._worker(n);if(e.isDisposed())return;const l=await o.getFormattingEditsAfterKeystroke(n.toString(),a,i,L._convertOptions(s));return l&&!e.isDisposed()?l.map((t=>this._convertTextChanges(e,t))):void 0}},M=class extends L{async provideCodeActions(e,t,i,s){const r=e.uri,n=e.getOffsetAt({lineNumber:t.startLineNumber,column:t.startColumn}),a=e.getOffsetAt({lineNumber:t.endLineNumber,column:t.endColumn}),o=L._convertOptions(e.getOptions()),l=i.markers.filter((e=>e.code)).map((e=>e.code)).map(Number),c=await this._worker(r);if(e.isDisposed())return;const d=await c.getCodeFixesAtPosition(r.toString(),n,a,l,o);if(!d||e.isDisposed())return{actions:[],dispose:()=>{}};return{actions:d.filter((e=>0===e.changes.filter((e=>e.isNewFile)).length)).map((t=>this._tsCodeFixActionToMonacoCodeAction(e,i,t))),dispose:()=>{}}}_tsCodeFixActionToMonacoCodeAction(e,t,i){const s=[];for(const r of i.changes)for(const t of r.textChanges)s.push({resource:e.uri,versionId:void 0,textEdit:{range:this._textSpanToRange(e,t.span),text:t.newText}});return{title:i.description,edit:{edits:s},diagnostics:t.markers,kind:"quickfix"}}},K=class extends f{constructor(e,t){super(t),this._libFiles=e}async provideRenameEdits(e,t,i,s){const r=e.uri,n=r.toString(),a=e.getOffsetAt(t),o=await this._worker(r);if(e.isDisposed())return;const l=await o.getRenameInfo(n,a,{allowRenameOfImportPath:!1});if(!1===l.canRename)return{edits:[],rejectReason:l.localizedErrorMessage};if(void 0!==l.fileToRename)throw new Error("Renaming files is not supported.");const c=await o.findRenameLocations(n,a,!1,!1,!1);if(!c||e.isDisposed())return;const d=[];for(const u of c){const e=this._libFiles.getOrCreateModel(u.fileName);if(!e)throw new Error(`Unknown file ${u.fileName}.`);d.push({resource:e.uri,versionId:void 0,textEdit:{range:this._textSpanToRange(e,u.textSpan),text:i}})}return{edits:d}}},R=class extends f{async provideInlayHints(e,t,i){const s=e.uri,r=s.toString(),n=e.getOffsetAt({lineNumber:t.startLineNumber,column:t.startColumn}),a=e.getOffsetAt({lineNumber:t.endLineNumber,column:t.endColumn}),o=await this._worker(s);if(e.isDisposed())return null;return{hints:(await o.provideInlayHints(r,n,a)).map((t=>({...t,label:t.text,position:e.getPositionAt(t.position),kind:this._convertHintKind(t.kind)}))),dispose:()=>{}}}_convertHintKind(e){return"Parameter"===e?g.languages.InlayHintKind.Parameter:g.languages.InlayHintKind.Type}};function E(e){P=W(e,"typescript")}function H(e){T=W(e,"javascript")}function V(){return new Promise(((e,t)=>{if(!T)return t("JavaScript not registered!");e(T)}))}function j(){return new Promise(((e,t)=>{if(!P)return t("TypeScript not registered!");e(P)}))}function W(e,t){const i=[],s=[],r=new p(t,e);i.push(r);const n=(...e)=>r.getLanguageServiceWorker(...e),a=new y(n);return function(){const{modeConfiguration:i}=e;B(s),i.completionItems&&s.push(g.languages.registerCompletionItemProvider(t,new w(n))),i.signatureHelp&&s.push(g.languages.registerSignatureHelpProvider(t,new x(n))),i.hovers&&s.push(g.languages.registerHoverProvider(t,new k(n))),i.documentHighlights&&s.push(g.languages.registerDocumentHighlightProvider(t,new v(n))),i.definitions&&s.push(g.languages.registerDefinitionProvider(t,new C(a,n))),i.references&&s.push(g.languages.registerReferenceProvider(t,new D(a,n))),i.documentSymbols&&s.push(g.languages.registerDocumentSymbolProvider(t,new A(n))),i.rename&&s.push(g.languages.registerRenameProvider(t,new K(a,n))),i.documentRangeFormattingEdits&&s.push(g.languages.registerDocumentRangeFormattingEditProvider(t,new O(n))),i.onTypeFormattingEdits&&s.push(g.languages.registerOnTypeFormattingEditProvider(t,new N(n))),i.codeActions&&s.push(g.languages.registerCodeActionProvider(t,new M(n))),i.inlayHints&&s.push(g.languages.registerInlayHintsProvider(t,new R(n))),i.diagnostics&&s.push(new _(a,e,t,n))}(),i.push(function(e){return{dispose:()=>B(e)}}(s)),n}function B(e){for(;e.length;)e.pop().dispose()}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/8986.de287636.chunk.js b/ydb/core/viewer/monitoring/static/js/8986.de287636.chunk.js deleted file mode 100644 index 7c525b529d08..000000000000 --- a/ydb/core/viewer/monitoring/static/js/8986.de287636.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 8986.de287636.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[8986],{58986:(e,t,r)=>{r.r(t),r.d(t,{conf:()=>h,language:()=>u});var o,i,n=r(80781),a=Object.defineProperty,m=Object.getOwnPropertyDescriptor,s=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,l=(e,t,r,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of s(t))c.call(e,i)||i===r||a(e,i,{get:()=>t[i],enumerable:!(o=m(t,i))||o.enumerable});return e},d={};l(d,o=n,"default"),i&&l(i,o,"default");var p=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],h={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,comments:{blockComment:["\x3c!--","--\x3e"]},brackets:[["\x3c!--","--\x3e"],["<",">"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"<",close:">"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/(\w[\w\d]*)\s*>$/i,action:{indentAction:d.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${p.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:d.languages.IndentAction.Indent}}]},u={defaultToken:"",tokenPostfix:"",tokenizer:{root:[[/@@@@/],[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.root"}],[/)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)(script)/,["delimiter.html",{token:"tag.html",next:"@script"}]],[/(<)(style)/,["delimiter.html",{token:"tag.html",next:"@style"}]],[/(<)([:\w\-]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)([\w\-]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/]+/,"metatag.content.html"],[/>/,"metatag.html","@pop"]],comment:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.comment"}],[/-->/,"comment.html","@pop"],[/[^-]+/,"comment.content.html"],[/./,"comment.content.html"]],otherTag:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.otherTag"}],[/\/?>/,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.script"}],[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],scriptAfterType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.scriptAfterType"}],[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.scriptAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.text/javascript",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.scriptWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInEmbeddedState.scriptEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],style:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.style"}],[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter.html","tag.html",{token:"delimiter.html",next:"@pop"}]]],styleAfterType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.styleAfterType"}],[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.styleAfterTypeEquals"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.text/css",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInSimpleState.styleWithCustomType.$S2"}],[/>/,{token:"delimiter.html",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/@[^@]/,{token:"@rematch",switchTo:"@razorInEmbeddedState.styleEmbedded.$S2",nextEmbedded:"@pop"}],[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}]],razorInSimpleState:[[/@\*/,"comment.cs","@razorBlockCommentTopLevel"],[/@[{(]/,"metatag.cs","@razorRootTopLevel"],[/(@)(\s*[\w]+)/,["metatag.cs",{token:"identifier.cs",switchTo:"@$S2.$S3"}]],[/[})]/,{token:"metatag.cs",switchTo:"@$S2.$S3"}],[/\*@/,{token:"comment.cs",switchTo:"@$S2.$S3"}]],razorInEmbeddedState:[[/@\*/,"comment.cs","@razorBlockCommentTopLevel"],[/@[{(]/,"metatag.cs","@razorRootTopLevel"],[/(@)(\s*[\w]+)/,["metatag.cs",{token:"identifier.cs",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}]],[/[})]/,{token:"metatag.cs",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}],[/\*@/,{token:"comment.cs",switchTo:"@$S2.$S3",nextEmbedded:"$S3"}]],razorBlockCommentTopLevel:[[/\*@/,"@rematch","@pop"],[/[^*]+/,"comment.cs"],[/./,"comment.cs"]],razorBlockComment:[[/\*@/,"comment.cs","@pop"],[/[^*]+/,"comment.cs"],[/./,"comment.cs"]],razorRootTopLevel:[[/\{/,"delimiter.bracket.cs","@razorRoot"],[/\(/,"delimiter.parenthesis.cs","@razorRoot"],[/[})]/,"@rematch","@pop"],{include:"razorCommon"}],razorRoot:[[/\{/,"delimiter.bracket.cs","@razorRoot"],[/\(/,"delimiter.parenthesis.cs","@razorRoot"],[/\}/,"delimiter.bracket.cs","@pop"],[/\)/,"delimiter.parenthesis.cs","@pop"],{include:"razorCommon"}],razorCommon:[[/[a-zA-Z_]\w*/,{cases:{"@razorKeywords":{token:"keyword.cs"},"@default":"identifier.cs"}}],[/[\[\]]/,"delimiter.array.cs"],[/[ \t\r\n]+/],[/\/\/.*$/,"comment.cs"],[/@\*/,"comment.cs","@razorBlockComment"],[/"([^"]*)"/,"string.cs"],[/'([^']*)'/,"string.cs"],[/(<)([\w\-]+)(\/>)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)([\w\-]+)(>)/,["delimiter.html","tag.html","delimiter.html"]],[/(<\/)([\w\-]+)(>)/,["delimiter.html","tag.html","delimiter.html"]],[/[\+\-\*\%\&\|\^\~\!\=\<\>\/\?\;\:\.\,]/,"delimiter.cs"],[/\d*\d+[eE]([\-+]?\d+)?/,"number.float.cs"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float.cs"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F]/,"number.hex.cs"],[/0[0-7']*[0-7]/,"number.octal.cs"],[/0[bB][0-1']*[0-1]/,"number.binary.cs"],[/\d[\d']*/,"number.cs"],[/\d/,"number.cs"]]},razorKeywords:["abstract","as","async","await","base","bool","break","by","byte","case","catch","char","checked","class","const","continue","decimal","default","delegate","do","double","descending","explicit","event","extern","else","enum","false","finally","fixed","float","for","foreach","from","goto","group","if","implicit","in","int","interface","internal","into","is","lock","long","nameof","new","null","namespace","object","operator","out","override","orderby","params","private","protected","public","readonly","ref","return","switch","struct","sbyte","sealed","short","sizeof","stackalloc","static","string","select","this","throw","true","try","typeof","uint","ulong","unchecked","unsafe","ushort","using","var","virtual","volatile","void","when","while","where","yield","model","inject"],escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/89922.e5924c1e.chunk.js b/ydb/core/viewer/monitoring/static/js/89922.e5924c1e.chunk.js new file mode 100644 index 000000000000..657ce1309b0e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/89922.e5924c1e.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[89922],{89922:function(e,_,a){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var a=_(e),o={name:"pt-br",weekdays:"domingo_segunda-feira_ter\xe7a-feira_quarta-feira_quinta-feira_sexta-feira_s\xe1bado".split("_"),weekdaysShort:"dom_seg_ter_qua_qui_sex_s\xe1b".split("_"),weekdaysMin:"Do_2\xaa_3\xaa_4\xaa_5\xaa_6\xaa_S\xe1".split("_"),months:"janeiro_fevereiro_mar\xe7o_abril_maio_junho_julho_agosto_setembro_outubro_novembro_dezembro".split("_"),monthsShort:"jan_fev_mar_abr_mai_jun_jul_ago_set_out_nov_dez".split("_"),ordinal:function(e){return e+"\xba"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY [\xe0s] HH:mm",LLLL:"dddd, D [de] MMMM [de] YYYY [\xe0s] HH:mm"},relativeTime:{future:"em %s",past:"h\xe1 %s",s:"poucos segundos",m:"um minuto",mm:"%d minutos",h:"uma hora",hh:"%d horas",d:"um dia",dd:"%d dias",M:"um m\xeas",MM:"%d meses",y:"um ano",yy:"%d anos"}};return a.default.locale(o,null,!0),o}(a(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90099.e646c3f9.chunk.js b/ydb/core/viewer/monitoring/static/js/90099.e646c3f9.chunk.js new file mode 100644 index 000000000000..0ada31f62bf6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90099.e646c3f9.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90099],{6156:(e,t,l)=>{l.d(t,{F:()=>_});var n=l(59284),a=l(81240),o=l(84476),i=l(80604),r=l(99991),s=l(63365),c=l(46423),d=l(87184);const m=n.createContext(null),u=()=>{const e=n.useContext(m);if(!e)throw new Error('Alert: `useAlertContext` hook is used out of "AlertContext"');return e},v=e=>{const{view:t}=u();return n.createElement(o.$,Object.assign({view:"filled"===t?"normal-contrast":void 0},e))};var w=l(69220);const p=(0,w.om)("alert"),g=({layout:e,view:t,children:l})=>n.createElement(m.Provider,{value:{layout:e,view:t}},l);var h=l(18677),f=l(10800),E=l(45720),b=l(43937),A=l(5744),y=l(70825),C=l(71153),N=l(94420);const x=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",d:"m14.61 6.914-7.632 8.08a1.614 1.614 0 0 1-2.69-1.66L5.5 10H2.677A1.677 1.677 0 0 1 1.12 7.7l2.323-5.807A2.22 2.22 0 0 1 5.5.5h4c.968 0 1.637.967 1.298 1.873L10 4.5h3.569a1.431 1.431 0 0 1 1.04 2.414"}));var k=l(27612);const z={danger:{filled:h.A,outlined:f.A},info:{filled:E.A,outlined:b.A},success:{filled:A.A,outlined:y.A},warning:{filled:C.A,outlined:N.A},utility:{filled:x,outlined:k.A},normal:null};var L=l(98089);var T=l(72837);const R=JSON.parse('{"label_close":"Close"}'),I=JSON.parse('{"label_close":"\u0417\u0430\u043a\u0440\u044b\u0442\u044c"}'),O=(0,T.N)({en:R,ru:I},"Alert"),_=e=>{const{theme:t="normal",view:l="filled",layout:m="vertical",message:u,className:v,corners:w,style:h,onClose:f,align:E,qa:b}=e;return n.createElement(g,{layout:m,view:l},n.createElement(i.Z,{style:h,className:p({corners:w},(0,c.Y)({py:4,px:5},v)),theme:t,view:l,qa:b},n.createElement(d.s,{gap:"3",alignItems:E},"undefined"===typeof e.icon?n.createElement(_.Icon,{theme:t,view:l}):e.icon,n.createElement(d.s,{direction:"vertical"===m?"column":"row",gap:"5",grow:!0},n.createElement(d.s,{gap:"2",grow:!0,className:p("text-content")},n.createElement(d.s,{direction:"column",gap:"1",grow:!0,justifyContent:E},"string"===typeof e.title?n.createElement(_.Title,{text:e.title}):e.title,u)),Array.isArray(e.actions)?n.createElement(_.Actions,{items:e.actions}):e.actions),f&&n.createElement(o.$,{view:"flat",className:p("close-btn"),onClick:f,extraProps:{"aria-label":O("label_close")}},n.createElement(r.I,{data:a.A,size:18,className:(0,s.$)({color:"secondary"})})))))};_.Icon=({className:e,theme:t,view:l="filled",size:a=18})=>{const o=z[t];if(!o)return null;let i;return"success"===t?i="positive":"normal"!==t&&(i=t),n.createElement("div",{className:p("icon",(0,s.$)({color:i},e))},n.createElement(r.I,{data:o[l],size:a}))},_.Title=({text:e,className:t})=>n.createElement(L.E,{variant:"subheader-2",className:p("title",t)},e),_.Actions=({items:e,children:t,className:l})=>{const{layout:a}=u();return n.createElement(d.s,{className:p("actions",{minContent:"horizontal"===a},l),direction:"row",gap:"3",wrap:!0,alignItems:"horizontal"===a?"center":"flex-start"},(null===e||void 0===e?void 0:e.map((({handler:e,text:t},l)=>n.createElement(v,{key:l,onClick:e},t))))||t)},_.Action=v},10800:(e,t,l)=>{l.d(t,{A:()=>a});var n=l(59284);const a=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.5 8a5.5 5.5 0 1 1-11 0 5.5 5.5 0 0 1 11 0M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},18677:(e,t,l)=>{l.d(t,{A:()=>a});var n=l(59284);const a=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},80604:(e,t,l)=>{l.d(t,{Z:()=>s});var n=l(27145),a=l(59284),o=l(46734),i=l(9296);const r=(0,l(69220).om)("card"),s=a.forwardRef((function(e,t){const{type:l="container",theme:s,view:c,size:d="m",children:m,className:u,onClick:v,disabled:w,selected:p}=e,g=(0,n.Tt)(e,["type","theme","view","size","children","className","onClick","disabled","selected"]),h="selection"===l,f="container"===l,E=("action"===l||h)&&Boolean(v)&&!w,b=f?"normal":void 0,A=f||h?"outlined":void 0,y=E?v:void 0,{onKeyDown:C}=(0,o.N)(v);return a.createElement(i.a,Object.assign({ref:t,role:E?"button":void 0,className:r({theme:s||b,view:c||A,type:l,selected:p,size:d,disabled:w,clickable:E},u),onClick:y,onKeyDown:E?C:void 0,tabIndex:E?0:void 0},g),m)}))},90099:(e,t,l)=>{l.r(t),l.d(t,{TopPanel:()=>s});var n=l(59284),a=l(6156),o=l(49034),i=l(16258);l(82435);const r=({topAlert:e})=>{const t=n.useRef(null),l=(e=>{const[t,l]=n.useState(0);return n.useEffect((()=>{if(e.current){const{current:t}=e;l(t.clientHeight)}}),[e]),t})(t),a=n.useCallback((e=>{const t=document.getElementsByClassName("g-root").item(0);null===t||void 0===t||t.style.setProperty("--gn-aside-top-panel-height",e+"px")}),[]),i=n.useCallback((()=>{var e;t.current&&a((null===(e=t.current)||void 0===e?void 0:e.clientHeight)||0)}),[t,a]);return n.useLayoutEffect((()=>{const t=(0,o.d)(i,200,{leading:!0});return e&&(window.addEventListener("resize",t),t()),()=>{window.removeEventListener("resize",t),a(0)}}),[e,l,t,i,a]),{topRef:t,updateTopSize:i}},s=({topAlert:e})=>{const{topRef:t,updateTopSize:l}=r({topAlert:e}),[o,s]=n.useState(!0),c=n.useCallback((()=>{var t;s(!1),null===(t=null===e||void 0===e?void 0:e.onCloseTopAlert)||void 0===t||t.call(e)}),[e]);return n.useEffect((()=>{o||l()}),[o,l]),e&&e.message?n.createElement("div",{ref:t,className:(0,i.b)("pane-top",{opened:o})},o&&n.createElement(n.Fragment,null,n.createElement(a.F,{className:(0,i.b)("pane-top-alert",{centered:e.centered,dense:e.dense}),corners:"square",layout:"horizontal",align:e.align,theme:e.theme||"warning",view:e.view,icon:e.icon,title:e.title,message:e.message,actions:e.actions,onClose:e.closable?c:void 0}),n.createElement("div",{className:(0,i.b)("pane-top-divider")}))):null}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9010.4bfaf5fa.chunk.js b/ydb/core/viewer/monitoring/static/js/9010.4bfaf5fa.chunk.js deleted file mode 100644 index 51415f7d0a3e..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9010.4bfaf5fa.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9010.4bfaf5fa.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9010],{99010:(e,t,i)=>{i.r(t),i.d(t,{conf:()=>o,language:()=>n});var o={comments:{lineComment:"COMMENT"},brackets:[["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:":",close:"."}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"`",close:"`"},{open:'"',close:'"'},{open:"'",close:"'"},{open:":",close:"."}],folding:{markers:{start:new RegExp("^\\s*(::\\s*|COMMENT\\s+)#region"),end:new RegExp("^\\s*(::\\s*|COMMENT\\s+)#endregion")}}},n={tokenPostfix:".lexon",ignoreCase:!0,keywords:["lexon","lex","clause","terms","contracts","may","pay","pays","appoints","into","to"],typeKeywords:["amount","person","key","time","date","asset","text"],operators:["less","greater","equal","le","gt","or","and","add","added","subtract","subtracted","multiply","multiplied","times","divide","divided","is","be","certified"],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,"delimiter"],[/\d*\.\d*\.\d*/,"number.semver"],[/\d*\.\d+([eE][\-+]?\d+)?/,"number.float"],[/0[xX][0-9a-fA-F]+/,"number.hex"],[/\d+/,"number"],[/[;,.]/,"delimiter"]],quoted_identifier:[[/[^\\"]+/,"identifier"],[/"/,{token:"identifier.quote",bracket:"@close",next:"@pop"}]],space_identifier_until_period:[[":","delimiter"],[" ",{token:"white",next:"@identifier_rest"}]],identifier_until_period:[{include:"@whitespace"},[":",{token:"delimiter",next:"@identifier_rest"}],[/[^\\.]+/,"identifier"],[/\./,{token:"delimiter",bracket:"@close",next:"@pop"}]],identifier_rest:[[/[^\\.]+/,"identifier"],[/\./,{token:"delimiter",bracket:"@close",next:"@pop"}]],semver:[{include:"@whitespace"},[":","delimiter"],[/\d*\.\d*\.\d*/,{token:"number.semver",bracket:"@close",next:"@pop"}]],whitespace:[[/[ \t\r\n]+/,"white"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90118.4fc97e01.chunk.js b/ydb/core/viewer/monitoring/static/js/90118.4fc97e01.chunk.js new file mode 100644 index 000000000000..cea782e01fa6 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90118.4fc97e01.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 90118.4fc97e01.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90118],{90118:(e,t,n)=>{n.r(t),n.d(t,{TagAngleInterpolationBracket:()=>B,TagAngleInterpolationDollar:()=>D,TagAutoInterpolationBracket:()=>w,TagAutoInterpolationDollar:()=>v,TagBracketInterpolationBracket:()=>C,TagBracketInterpolationDollar:()=>E});var o,i,_=n(80781),r=Object.defineProperty,a=Object.getOwnPropertyDescriptor,s=Object.getOwnPropertyNames,u=Object.prototype.hasOwnProperty,d=(e,t,n,o)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let i of s(t))u.call(e,i)||i===n||r(e,i,{get:()=>t[i],enumerable:!(o=a(t,i))||o.enumerable});return e},c={};d(c,o=_,"default"),i&&d(i,o,"default");var l=["assign","flush","ftl","return","global","import","include","break","continue","local","nested","nt","setting","stop","t","lt","rt","fallback"],k=["attempt","autoesc","autoEsc","compress","comment","escape","noescape","function","if","list","items","sep","macro","noparse","noParse","noautoesc","noAutoEsc","outputformat","switch","visit","recurse"],p={close:">",id:"angle",open:"<"},g={close:"\\]",id:"bracket",open:"\\["},A={close:"[>\\]]",id:"auto",open:"[<\\[]"},m={close:"\\}",id:"dollar",open1:"\\$",open2:"\\{"},b={close:"\\]",id:"bracket",open1:"\\[",open2:"="};function f(e){return{brackets:[["<",">"],["[","]"],["(",")"],["{","}"]],comments:{blockComment:[`${e.open}--`,`--${e.close}`]},autoCloseBefore:"\n\r\t }]),.:;=",autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"}],folding:{markers:{start:new RegExp(`${e.open}#(?:${k.join("|")})([^/${e.close}]*(?!/)${e.close})[^${e.open}]*$`),end:new RegExp(`${e.open}/#(?:${k.join("|")})[\\r\\n\\t ]*>`)}},onEnterRules:[{beforeText:new RegExp(`${e.open}#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/${e.close}]*(?!/)${e.close})[^${e.open}]*$`),afterText:new RegExp(`^${e.open}/#([a-zA-Z_]+)[\\r\\n\\t ]*${e.close}$`),action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`${e.open}#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/${e.close}]*(?!/)${e.close})[^${e.open}]*$`),action:{indentAction:c.languages.IndentAction.Indent}}]}}function F(){return{brackets:[["<",">"],["[","]"],["(",")"],["{","}"]],autoCloseBefore:"\n\r\t }]),.:;=",autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],surroundingPairs:[{open:'"',close:'"'},{open:"'",close:"'"},{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"}],folding:{markers:{start:new RegExp(`[<\\[]#(?:${k.join("|")})([^/>\\]]*(?!/)[>\\]])[^<\\[]*$`),end:new RegExp(`[<\\[]/#(?:${k.join("|")})[\\r\\n\\t ]*>`)}},onEnterRules:[{beforeText:new RegExp(`[<\\[]#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/>\\]]*(?!/)[>\\]])[^[<\\[]]*$`),afterText:new RegExp("^[<\\[]/#([a-zA-Z_]+)[\\r\\n\\t ]*[>\\]]$"),action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`[<\\[]#(?!(?:${l.join("|")}))([a-zA-Z_]+)([^/>\\]]*(?!/)[>\\]])[^[<\\[]]*$`),action:{indentAction:c.languages.IndentAction.Indent}}]}}function x(e,t){const n=`_${e.id}_${t.id}`,o=e=>e.replace(/__id__/g,n),i=e=>{const t=e.source.replace(/__id__/g,n);return new RegExp(t,e.flags)};return{unicode:!0,includeLF:!1,start:o("default__id__"),ignoreCase:!1,defaultToken:"invalid",tokenPostfix:".freemarker2",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],[o("open__id__")]:new RegExp(e.open),[o("close__id__")]:new RegExp(e.close),[o("iOpen1__id__")]:new RegExp(t.open1),[o("iOpen2__id__")]:new RegExp(t.open2),[o("iClose__id__")]:new RegExp(t.close),[o("startTag__id__")]:i(/(@open__id__)(#)/),[o("endTag__id__")]:i(/(@open__id__)(\/#)/),[o("startOrEndTag__id__")]:i(/(@open__id__)(\/?#)/),[o("closeTag1__id__")]:i(/((?:@blank)*)(@close__id__)/),[o("closeTag2__id__")]:i(/((?:@blank)*\/?)(@close__id__)/),blank:/[ \t\n\r]/,keywords:["false","true","in","as","using"],directiveStartCloseTag1:/attempt|recover|sep|auto[eE]sc|no(?:autoe|AutoE)sc|compress|default|no[eE]scape|comment|no[pP]arse/,directiveStartCloseTag2:/else|break|continue|return|stop|flush|t|lt|rt|nt|nested|recurse|fallback|ftl/,directiveStartBlank:/if|else[iI]f|list|for[eE]ach|switch|case|assign|global|local|include|import|function|macro|transform|visit|stop|return|call|setting|output[fF]ormat|nested|recurse|escape|ftl|items/,directiveEndCloseTag1:/if|list|items|sep|recover|attempt|for[eE]ach|local|global|assign|function|macro|output[fF]ormat|auto[eE]sc|no(?:autoe|AutoE)sc|compress|transform|switch|escape|no[eE]scape/,escapedChar:/\\(?:[ntrfbgla\\'"\{=]|(?:x[0-9A-Fa-f]{1,4}))/,asciiDigit:/[0-9]/,integer:/[0-9]+/,nonEscapedIdStartChar:/[\$@-Z_a-z\u00AA\u00B5\u00BA\u00C0-\u00D6\u00D8-\u00F6\u00F8-\u1FFF\u2071\u207F\u2090-\u209C\u2102\u2107\u210A-\u2113\u2115\u2119-\u211D\u2124\u2126\u2128\u212A-\u212D\u212F-\u2139\u213C-\u213F\u2145-\u2149\u214E\u2183-\u2184\u2C00-\u2C2E\u2C30-\u2C5E\u2C60-\u2CE4\u2CEB-\u2CEE\u2CF2-\u2CF3\u2D00-\u2D25\u2D27\u2D2D\u2D30-\u2D67\u2D6F\u2D80-\u2D96\u2DA0-\u2DA6\u2DA8-\u2DAE\u2DB0-\u2DB6\u2DB8-\u2DBE\u2DC0-\u2DC6\u2DC8-\u2DCE\u2DD0-\u2DD6\u2DD8-\u2DDE\u2E2F\u3005-\u3006\u3031-\u3035\u303B-\u303C\u3040-\u318F\u31A0-\u31BA\u31F0-\u31FF\u3300-\u337F\u3400-\u4DB5\u4E00-\uA48C\uA4D0-\uA4FD\uA500-\uA60C\uA610-\uA62B\uA640-\uA66E\uA67F-\uA697\uA6A0-\uA6E5\uA717-\uA71F\uA722-\uA788\uA78B-\uA78E\uA790-\uA793\uA7A0-\uA7AA\uA7F8-\uA801\uA803-\uA805\uA807-\uA80A\uA80C-\uA822\uA840-\uA873\uA882-\uA8B3\uA8D0-\uA8D9\uA8F2-\uA8F7\uA8FB\uA900-\uA925\uA930-\uA946\uA960-\uA97C\uA984-\uA9B2\uA9CF-\uA9D9\uAA00-\uAA28\uAA40-\uAA42\uAA44-\uAA4B\uAA50-\uAA59\uAA60-\uAA76\uAA7A\uAA80-\uAAAF\uAAB1\uAAB5-\uAAB6\uAAB9-\uAABD\uAAC0\uAAC2\uAADB-\uAADD\uAAE0-\uAAEA\uAAF2-\uAAF4\uAB01-\uAB06\uAB09-\uAB0E\uAB11-\uAB16\uAB20-\uAB26\uAB28-\uAB2E\uABC0-\uABE2\uABF0-\uABF9\uAC00-\uD7A3\uD7B0-\uD7C6\uD7CB-\uD7FB\uF900-\uFB06\uFB13-\uFB17\uFB1D\uFB1F-\uFB28\uFB2A-\uFB36\uFB38-\uFB3C\uFB3E\uFB40-\uFB41\uFB43-\uFB44\uFB46-\uFBB1\uFBD3-\uFD3D\uFD50-\uFD8F\uFD92-\uFDC7\uFDF0-\uFDFB\uFE70-\uFE74\uFE76-\uFEFC\uFF10-\uFF19\uFF21-\uFF3A\uFF41-\uFF5A\uFF66-\uFFBE\uFFC2-\uFFC7\uFFCA-\uFFCF\uFFD2-\uFFD7\uFFDA-\uFFDC]/,escapedIdChar:/\\[\-\.:#]/,idStartChar:/(?:@nonEscapedIdStartChar)|(?:@escapedIdChar)/,id:/(?:@idStartChar)(?:(?:@idStartChar)|(?:@asciiDigit))*/,specialHashKeys:/\*\*|\*|false|true|in|as|using/,namedSymbols:/<=|>=|\\lte|\\lt|<|\\gte|\\gt|>|&&|\\and|->|->|==|!=|\+=|-=|\*=|\/=|%=|\+\+|--|<=|&&|\|\||:|\.\.\.|\.\.\*|\.\.<|\.\.!|\?\?|=|<|\+|-|\*|\/|%|\||\.\.|\?|!|&|\.|,|;/,arrows:["->","->"],delimiters:[";",":",",","."],stringOperators:["lte","lt","gte","gt"],noParseTags:["noparse","noParse","comment"],tokenizer:{[o("default__id__")]:[{include:o("@directive_token__id__")},{include:o("@interpolation_and_text_token__id__")}],[o("fmExpression__id__.directive")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@directive_end_token__id__")},{include:o("@expression_token__id__")}],[o("fmExpression__id__.interpolation")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@expression_token__id__")},{include:o("@greater_operators_token__id__")}],[o("inParen__id__.plain")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@directive_end_token__id__")},{include:o("@expression_token__id__")}],[o("inParen__id__.gt")]:[{include:o("@blank_and_expression_comment_token__id__")},{include:o("@expression_token__id__")},{include:o("@greater_operators_token__id__")}],[o("noSpaceExpression__id__")]:[{include:o("@no_space_expression_end_token__id__")},{include:o("@directive_end_token__id__")},{include:o("@expression_token__id__")}],[o("unifiedCall__id__")]:[{include:o("@unified_call_token__id__")}],[o("singleString__id__")]:[{include:o("@string_single_token__id__")}],[o("doubleString__id__")]:[{include:o("@string_double_token__id__")}],[o("rawSingleString__id__")]:[{include:o("@string_single_raw_token__id__")}],[o("rawDoubleString__id__")]:[{include:o("@string_double_raw_token__id__")}],[o("expressionComment__id__")]:[{include:o("@expression_comment_token__id__")}],[o("noParse__id__")]:[{include:o("@no_parse_token__id__")}],[o("terseComment__id__")]:[{include:o("@terse_comment_token__id__")}],[o("directive_token__id__")]:[[i(/(?:@startTag__id__)(@directiveStartCloseTag1)(?:@closeTag1__id__)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{cases:{"@noParseTags":{token:"tag",next:o("@noParse__id__.$3")},"@default":{token:"tag"}}},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(?:@startTag__id__)(@directiveStartCloseTag2)(?:@closeTag2__id__)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(?:@startTag__id__)(@directiveStartBlank)(@blank)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"",next:o("@fmExpression__id__.directive")}]],[i(/(?:@endTag__id__)(@directiveEndCloseTag1)(?:@closeTag1__id__)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(@open__id__)(@)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive",next:o("@unifiedCall__id__")}]],[i(/(@open__id__)(\/@)((?:(?:@id)(?:\.(?:@id))*)?)(?:@closeTag1__id__)/),[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive"}]],[i(/(@open__id__)#--/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:{token:"comment",next:o("@terseComment__id__")}],[i(/(?:@startOrEndTag__id__)([a-zA-Z_]+)/),"auto"===e.id?{cases:{"$1==<":{token:"@rematch",switchTo:`@default_angle_${t.id}`},"$1==[":{token:"@rematch",switchTo:`@default_bracket_${t.id}`}}}:[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag.invalid",next:o("@fmExpression__id__.directive")}]]],[o("interpolation_and_text_token__id__")]:[[i(/(@iOpen1__id__)(@iOpen2__id__)/),[{token:"bracket"===t.id?"@brackets.interpolation":"delimiter.interpolation"},{token:"bracket"===t.id?"delimiter.interpolation":"@brackets.interpolation",next:o("@fmExpression__id__.interpolation")}]],[/[\$#<\[\{]|(?:@blank)+|[^\$<#\[\{\n\r\t ]+/,{token:"source"}]],[o("string_single_token__id__")]:[[/[^'\\]/,{token:"string"}],[/@escapedChar/,{token:"string.escape"}],[/'/,{token:"string",next:"@pop"}]],[o("string_double_token__id__")]:[[/[^"\\]/,{token:"string"}],[/@escapedChar/,{token:"string.escape"}],[/"/,{token:"string",next:"@pop"}]],[o("string_single_raw_token__id__")]:[[/[^']+/,{token:"string.raw"}],[/'/,{token:"string.raw",next:"@pop"}]],[o("string_double_raw_token__id__")]:[[/[^"]+/,{token:"string.raw"}],[/"/,{token:"string.raw",next:"@pop"}]],[o("expression_token__id__")]:[[/(r?)(['"])/,{cases:{"r'":[{token:"keyword"},{token:"string.raw",next:o("@rawSingleString__id__")}],'r"':[{token:"keyword"},{token:"string.raw",next:o("@rawDoubleString__id__")}],"'":[{token:"source"},{token:"string",next:o("@singleString__id__")}],'"':[{token:"source"},{token:"string",next:o("@doubleString__id__")}]}}],[/(?:@integer)(?:\.(?:@integer))?/,{cases:{"(?:@integer)":{token:"number"},"@default":{token:"number.float"}}}],[/(\.)(@blank*)(@specialHashKeys)/,[{token:"delimiter"},{token:""},{token:"identifier"}]],[/(?:@namedSymbols)/,{cases:{"@arrows":{token:"meta.arrow"},"@delimiters":{token:"delimiter"},"@default":{token:"operators"}}}],[/@id/,{cases:{"@keywords":{token:"keyword.$0"},"@stringOperators":{token:"operators"},"@default":{token:"identifier"}}}],[/[\[\]\(\)\{\}]/,{cases:{"\\[":{cases:{"$S2==gt":{token:"@brackets",next:o("@inParen__id__.gt")},"@default":{token:"@brackets",next:o("@inParen__id__.plain")}}},"\\]":{cases:{..."bracket"===t.id?{"$S2==interpolation":{token:"@brackets.interpolation",next:"@popall"}}:{},..."bracket"===e.id?{"$S2==directive":{token:"@brackets.directive",next:"@popall"}}:{},[o("$S1==inParen__id__")]:{token:"@brackets",next:"@pop"},"@default":{token:"@brackets"}}},"\\(":{token:"@brackets",next:o("@inParen__id__.gt")},"\\)":{cases:{[o("$S1==inParen__id__")]:{token:"@brackets",next:"@pop"},"@default":{token:"@brackets"}}},"\\{":{cases:{"$S2==gt":{token:"@brackets",next:o("@inParen__id__.gt")},"@default":{token:"@brackets",next:o("@inParen__id__.plain")}}},"\\}":{cases:{..."bracket"===t.id?{}:{"$S2==interpolation":{token:"@brackets.interpolation",next:"@popall"}},[o("$S1==inParen__id__")]:{token:"@brackets",next:"@pop"},"@default":{token:"@brackets"}}}}}],[/\$\{/,{token:"delimiter.invalid"}]],[o("blank_and_expression_comment_token__id__")]:[[/(?:@blank)+/,{token:""}],[/[<\[][#!]--/,{token:"comment",next:o("@expressionComment__id__")}]],[o("directive_end_token__id__")]:[[/>/,"bracket"===e.id?{token:"operators"}:{token:"@brackets.directive",next:"@popall"}],[i(/(\/)(@close__id__)/),[{token:"delimiter.directive"},{token:"@brackets.directive",next:"@popall"}]]],[o("greater_operators_token__id__")]:[[/>/,{token:"operators"}],[/>=/,{token:"operators"}]],[o("no_space_expression_end_token__id__")]:[[/(?:@blank)+/,{token:"",switchTo:o("@fmExpression__id__.directive")}]],[o("unified_call_token__id__")]:[[/(@id)((?:@blank)+)/,[{token:"tag"},{token:"",next:o("@fmExpression__id__.directive")}]],[i(/(@id)(\/?)(@close__id__)/),[{token:"tag"},{token:"delimiter.directive"},{token:"@brackets.directive",next:"@popall"}]],[/./,{token:"@rematch",next:o("@noSpaceExpression__id__")}]],[o("no_parse_token__id__")]:[[i(/(@open__id__)(\/#?)([a-zA-Z]+)((?:@blank)*)(@close__id__)/),{cases:{"$S2==$3":[{token:"@brackets.directive"},{token:"delimiter.directive"},{token:"tag"},{token:""},{token:"@brackets.directive",next:"@popall"}],"$S2==comment":[{token:"comment"},{token:"comment"},{token:"comment"},{token:"comment"},{token:"comment"}],"@default":[{token:"source"},{token:"source"},{token:"source"},{token:"source"},{token:"source"}]}}],[/[^<\[\-]+|[<\[\-]/,{cases:{"$S2==comment":{token:"comment"},"@default":{token:"source"}}}]],[o("expression_comment_token__id__")]:[[/--[>\]]/,{token:"comment",next:"@pop"}],[/[^\->\]]+|[>\]\-]/,{token:"comment"}]],[o("terse_comment_token__id__")]:[[i(/--(?:@close__id__)/),{token:"comment",next:"@popall"}],[/[^<\[\-]+|[<\[\-]/,{token:"comment"}]]}}}function $(e){const t=x(p,e),n=x(g,e),o=x(A,e);return{...t,...n,...o,unicode:!0,includeLF:!1,start:`default_auto_${e.id}`,ignoreCase:!1,defaultToken:"invalid",tokenPostfix:".freemarker2",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],tokenizer:{...t.tokenizer,...n.tokenizer,...o.tokenizer}}}var D={conf:f(p),language:x(p,m)},E={conf:f(g),language:x(g,m)},B={conf:f(p),language:x(p,b)},C={conf:f(g),language:x(g,b)},v={conf:F(),language:$(m)},w={conf:F(),language:$(b)}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9176.3f08336f.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/90118.4fc97e01.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/9176.3f08336f.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/90118.4fc97e01.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/902.a1b90b1b.chunk.js b/ydb/core/viewer/monitoring/static/js/902.a1b90b1b.chunk.js deleted file mode 100644 index afc42c64e222..000000000000 --- a/ydb/core/viewer/monitoring/static/js/902.a1b90b1b.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 902.a1b90b1b.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[902],{10902:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>i,language:()=>o});var i={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"}],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"',notIn:["string"]},{open:"'",close:"'",notIn:["string"]}],autoCloseBefore:".,=}])>' \n\t",indentationRules:{increaseIndentPattern:new RegExp("^((?!\\/\\/).)*(\\{[^}\"'`]*|\\([^)\"'`]*|\\[[^\\]\"'`]*)$"),decreaseIndentPattern:new RegExp("^((?!.*?\\/\\*).*\\*/)?\\s*[\\}\\]].*$")}},o={defaultToken:"",tokenPostfix:".proto",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}],symbols:/[=>/,{token:"@brackets",bracket:"@close",switchTo:"identifier"}]],field:[{include:"@whitespace"},["group",{cases:{"$S2==proto2":{token:"keyword",switchTo:"@groupDecl.$S2"}}}],[/(@identifier)(\s*)(=)/,["identifier","white",{token:"delimiter",next:"@pop"}]],[/@fullIdentifier|\./,{cases:{"@builtinTypes":"keyword","@default":"type.identifier"}}]],groupDecl:[{include:"@whitespace"},[/@identifier/,"identifier"],["=","operator"],[/{/,{token:"@brackets",bracket:"@open",switchTo:"@messageBody.$S2"}],{include:"@constant"}],type:[{include:"@whitespace"},[/@identifier/,"type.identifier","@pop"],[/./,"delimiter"]],identifier:[{include:"@whitespace"},[/@identifier/,"identifier","@pop"]],serviceDecl:[{include:"@whitespace"},[/@identifier/,"identifier"],[/{/,{token:"@brackets",bracket:"@open",switchTo:"@serviceBody.$S2"}]],serviceBody:[{include:"@whitespace"},{include:"@constant"},[/;/,"delimiter"],[/option\b/,"keyword","@option.$S2"],[/rpc\b/,"keyword","@rpc.$S2"],[/\[/,{token:"@brackets",bracket:"@open",next:"@options.$S2"}],[/}/,{token:"@brackets",bracket:"@close",next:"@pop"}]],rpc:[{include:"@whitespace"},[/@identifier/,"identifier"],[/\(/,{token:"@brackets",bracket:"@open",switchTo:"@request.$S2"}],[/{/,{token:"@brackets",bracket:"@open",next:"@methodOptions.$S2"}],[/;/,"delimiter","@pop"]],request:[{include:"@whitespace"},[/@messageType/,{cases:{stream:{token:"keyword",next:"@type.$S2"},"@default":"type.identifier"}}],[/\)/,{token:"@brackets",bracket:"@close",switchTo:"@returns.$S2"}]],returns:[{include:"@whitespace"},[/returns\b/,"keyword"],[/\(/,{token:"@brackets",bracket:"@open",switchTo:"@response.$S2"}]],response:[{include:"@whitespace"},[/@messageType/,{cases:{stream:{token:"keyword",next:"@type.$S2"},"@default":"type.identifier"}}],[/\)/,{token:"@brackets",bracket:"@close",switchTo:"@rpc.$S2"}]],methodOptions:[{include:"@whitespace"},{include:"@constant"},[/;/,"delimiter"],["option","keyword"],[/@optionName/,"annotation"],[/[()]/,"annotation.brackets"],[/=/,"operator"],[/}/,{token:"@brackets",bracket:"@close",next:"@pop"}]],comment:[[/[^\/*]+/,"comment"],[/\/\*/,"comment","@push"],["\\*/","comment","@pop"],[/[\/*]/,"comment"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,{token:"string.quote",bracket:"@close",next:"@pop"}]],stringSingle:[[/[^\\']+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/'/,{token:"string.quote",bracket:"@close",next:"@pop"}]],constant:[["@boolLit","keyword.constant"],["@hexLit","number.hex"],["@octalLit","number.octal"],["@decimalLit","number"],["@floatLit","number.float"],[/("([^"\\]|\\.)*|'([^'\\]|\\.)*)$/,"string.invalid"],[/"/,{token:"string.quote",bracket:"@open",next:"@string"}],[/'/,{token:"string.quote",bracket:"@open",next:"@stringSingle"}],[/{/,{token:"@brackets",bracket:"@open",next:"@prototext"}],[/identifier/,"identifier"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],prototext:[{include:"@whitespace"},{include:"@constant"},[/@identifier/,"identifier"],[/[:;]/,"delimiter"],[/}/,{token:"@brackets",bracket:"@close",next:"@pop"}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9025.6ae28867.chunk.js b/ydb/core/viewer/monitoring/static/js/9025.6ae28867.chunk.js deleted file mode 100644 index b0fdc68dfda6..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9025.6ae28867.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9025],{89025:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ky",weekdays:"\u0416\u0435\u043a\u0448\u0435\u043c\u0431\u0438_\u0414\u04af\u0439\u0448\u04e9\u043c\u0431\u04af_\u0428\u0435\u0439\u0448\u0435\u043c\u0431\u0438_\u0428\u0430\u0440\u0448\u0435\u043c\u0431\u0438_\u0411\u0435\u0439\u0448\u0435\u043c\u0431\u0438_\u0416\u0443\u043c\u0430_\u0418\u0448\u0435\u043c\u0431\u0438".split("_"),months:"\u044f\u043d\u0432\u0430\u0440\u044c_\u0444\u0435\u0432\u0440\u0430\u043b\u044c_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440\u0435\u043b\u044c_\u043c\u0430\u0439_\u0438\u044e\u043d\u044c_\u0438\u044e\u043b\u044c_\u0430\u0432\u0433\u0443\u0441\u0442_\u0441\u0435\u043d\u0442\u044f\u0431\u0440\u044c_\u043e\u043a\u0442\u044f\u0431\u0440\u044c_\u043d\u043e\u044f\u0431\u0440\u044c_\u0434\u0435\u043a\u0430\u0431\u0440\u044c".split("_"),weekStart:1,weekdaysShort:"\u0416\u0435\u043a_\u0414\u04af\u0439_\u0428\u0435\u0439_\u0428\u0430\u0440_\u0411\u0435\u0439_\u0416\u0443\u043c_\u0418\u0448\u0435".split("_"),monthsShort:"\u044f\u043d\u0432_\u0444\u0435\u0432_\u043c\u0430\u0440\u0442_\u0430\u043f\u0440_\u043c\u0430\u0439_\u0438\u044e\u043d\u044c_\u0438\u044e\u043b\u044c_\u0430\u0432\u0433_\u0441\u0435\u043d_\u043e\u043a\u0442_\u043d\u043e\u044f_\u0434\u0435\u043a".split("_"),weekdaysMin:"\u0416\u043a_\u0414\u0439_\u0428\u0439_\u0428\u0440_\u0411\u0439_\u0416\u043c_\u0418\u0448".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"%s \u0438\u0447\u0438\u043d\u0434\u0435",past:"%s \u043c\u0443\u0440\u0443\u043d",s:"\u0431\u0438\u0440\u043d\u0435\u0447\u0435 \u0441\u0435\u043a\u0443\u043d\u0434",m:"\u0431\u0438\u0440 \u043c\u04af\u043d\u04e9\u0442",mm:"%d \u043c\u04af\u043d\u04e9\u0442",h:"\u0431\u0438\u0440 \u0441\u0430\u0430\u0442",hh:"%d \u0441\u0430\u0430\u0442",d:"\u0431\u0438\u0440 \u043a\u04af\u043d",dd:"%d \u043a\u04af\u043d",M:"\u0431\u0438\u0440 \u0430\u0439",MM:"%d \u0430\u0439",y:"\u0431\u0438\u0440 \u0436\u044b\u043b",yy:"%d \u0436\u044b\u043b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90290.a7f1549c.chunk.js b/ydb/core/viewer/monitoring/static/js/90290.a7f1549c.chunk.js new file mode 100644 index 000000000000..bb8955bf4a4e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90290.a7f1549c.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90290],{90290:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"en-gb",weekdays:"Sunday_Monday_Tuesday_Wednesday_Thursday_Friday_Saturday".split("_"),weekdaysShort:"Sun_Mon_Tue_Wed_Thu_Fri_Sat".split("_"),weekdaysMin:"Su_Mo_Tu_We_Th_Fr_Sa".split("_"),months:"January_February_March_April_May_June_July_August_September_October_November_December".split("_"),monthsShort:"Jan_Feb_Mar_Apr_May_Jun_Jul_Aug_Sep_Oct_Nov_Dec".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"in %s",past:"%s ago",s:"a few seconds",m:"a minute",mm:"%d minutes",h:"an hour",hh:"%d hours",d:"a day",dd:"%d days",M:"a month",MM:"%d months",y:"a year",yy:"%d years"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},ordinal:function(e){var a=["th","st","nd","rd"],_=e%100;return"["+e+(a[(_-20)%10]||a[_]||a[0])+"]"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90330.7878a0d4.chunk.js b/ydb/core/viewer/monitoring/static/js/90330.7878a0d4.chunk.js new file mode 100644 index 000000000000..889565436b69 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90330.7878a0d4.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90330],{77071:e=>{function n(e){e.languages.powerquery={comment:{pattern:/(^|[^\\])(?:\/\*[\s\S]*?\*\/|\/\/.*)/,lookbehind:!0,greedy:!0},"quoted-identifier":{pattern:/#"(?:[^"\r\n]|"")*"(?!")/,greedy:!0},string:{pattern:/(?:#!)?"(?:[^"\r\n]|"")*"(?!")/,greedy:!0},constant:[/\bDay\.(?:Friday|Monday|Saturday|Sunday|Thursday|Tuesday|Wednesday)\b/,/\bTraceLevel\.(?:Critical|Error|Information|Verbose|Warning)\b/,/\bOccurrence\.(?:All|First|Last)\b/,/\bOrder\.(?:Ascending|Descending)\b/,/\bRoundingMode\.(?:AwayFromZero|Down|ToEven|TowardZero|Up)\b/,/\bMissingField\.(?:Error|Ignore|UseNull)\b/,/\bQuoteStyle\.(?:Csv|None)\b/,/\bJoinKind\.(?:FullOuter|Inner|LeftAnti|LeftOuter|RightAnti|RightOuter)\b/,/\bGroupKind\.(?:Global|Local)\b/,/\bExtraValues\.(?:Error|Ignore|List)\b/,/\bJoinAlgorithm\.(?:Dynamic|LeftHash|LeftIndex|PairwiseHash|RightHash|RightIndex|SortMerge)\b/,/\bJoinSide\.(?:Left|Right)\b/,/\bPrecision\.(?:Decimal|Double)\b/,/\bRelativePosition\.From(?:End|Start)\b/,/\bTextEncoding\.(?:Ascii|BigEndianUnicode|Unicode|Utf16|Utf8|Windows)\b/,/\b(?:Any|Binary|Date|DateTime|DateTimeZone|Duration|Function|Int16|Int32|Int64|Int8|List|Logical|None|Number|Record|Table|Text|Time)\.Type\b/,/\bnull\b/],boolean:/\b(?:false|true)\b/,keyword:/\b(?:and|as|each|else|error|if|in|is|let|meta|not|nullable|optional|or|otherwise|section|shared|then|try|type)\b|#(?:binary|date|datetime|datetimezone|duration|infinity|nan|sections|shared|table|time)\b/,function:{pattern:/(^|[^#\w.])[a-z_][\w.]*(?=\s*\()/i,lookbehind:!0},"data-type":{pattern:/\b(?:any|anynonnull|binary|date|datetime|datetimezone|duration|function|list|logical|none|number|record|table|text|time)\b/,alias:"class-name"},number:{pattern:/\b0x[\da-f]+\b|(?:[+-]?(?:\b\d+\.)?\b\d+|[+-]\.\d+|(^|[^.])\B\.\d+)(?:e[+-]?\d+)?\b/i,lookbehind:!0},operator:/[-+*\/&?@^]|<(?:=>?|>)?|>=?|=>?|\.\.\.?/,punctuation:/[,;\[\](){}]/},e.languages.pq=e.languages.powerquery,e.languages.mscript=e.languages.powerquery}e.exports=n,n.displayName="powerquery",n.aliases=[]},90330:(e,n,t)=>{t.d(n,{default:()=>i});var a=t(77071);const i=t.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90367.afe12186.chunk.js b/ydb/core/viewer/monitoring/static/js/90367.afe12186.chunk.js new file mode 100644 index 000000000000..9cc6dfce3daa --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90367.afe12186.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90367],{32918:(e,r,a)=>{var t=a(77831);function n(e){e.register(t),e.languages.racket=e.languages.extend("scheme",{"lambda-parameter":{pattern:/([(\[]lambda\s+[(\[])[^()\[\]'\s]+/,lookbehind:!0}}),e.languages.insertBefore("racket","string",{lang:{pattern:/^#lang.+/m,greedy:!0,alias:"keyword"}}),e.languages.rkt=e.languages.racket}e.exports=n,n.displayName="racket",n.aliases=["rkt"]},77831:e=>{function r(e){!function(e){e.languages.scheme={comment:/;.*|#;\s*(?:\((?:[^()]|\([^()]*\))*\)|\[(?:[^\[\]]|\[[^\[\]]*\])*\])|#\|(?:[^#|]|#(?!\|)|\|(?!#)|#\|(?:[^#|]|#(?!\|)|\|(?!#))*\|#)*\|#/,string:{pattern:/"(?:[^"\\]|\\.)*"/,greedy:!0},symbol:{pattern:/'[^()\[\]#'\s]+/,greedy:!0},char:{pattern:/#\\(?:[ux][a-fA-F\d]+\b|[-a-zA-Z]+\b|[\uD800-\uDBFF][\uDC00-\uDFFF]|\S)/,greedy:!0},"lambda-parameter":[{pattern:/((?:^|[^'`#])[(\[]lambda\s+)(?:[^|()\[\]'\s]+|\|(?:[^\\|]|\\.)*\|)/,lookbehind:!0},{pattern:/((?:^|[^'`#])[(\[]lambda\s+[(\[])[^()\[\]']+/,lookbehind:!0}],keyword:{pattern:/((?:^|[^'`#])[(\[])(?:begin|case(?:-lambda)?|cond(?:-expand)?|define(?:-library|-macro|-record-type|-syntax|-values)?|defmacro|delay(?:-force)?|do|else|except|export|guard|if|import|include(?:-ci|-library-declarations)?|lambda|let(?:rec)?(?:-syntax|-values|\*)?|let\*-values|only|parameterize|prefix|(?:quasi-?)?quote|rename|set!|syntax-(?:case|rules)|unless|unquote(?:-splicing)?|when)(?=[()\[\]\s]|$)/,lookbehind:!0},builtin:{pattern:/((?:^|[^'`#])[(\[])(?:abs|and|append|apply|assoc|ass[qv]|binary-port\?|boolean=?\?|bytevector(?:-append|-copy|-copy!|-length|-u8-ref|-u8-set!|\?)?|caar|cadr|call-with-(?:current-continuation|port|values)|call\/cc|car|cdar|cddr|cdr|ceiling|char(?:->integer|-ready\?|\?|<\?|<=\?|=\?|>\?|>=\?)|close-(?:input-port|output-port|port)|complex\?|cons|current-(?:error|input|output)-port|denominator|dynamic-wind|eof-object\??|eq\?|equal\?|eqv\?|error|error-object(?:-irritants|-message|\?)|eval|even\?|exact(?:-integer-sqrt|-integer\?|\?)?|expt|features|file-error\?|floor(?:-quotient|-remainder|\/)?|flush-output-port|for-each|gcd|get-output-(?:bytevector|string)|inexact\??|input-port(?:-open\?|\?)|integer(?:->char|\?)|lcm|length|list(?:->string|->vector|-copy|-ref|-set!|-tail|\?)?|make-(?:bytevector|list|parameter|string|vector)|map|max|member|memq|memv|min|modulo|negative\?|newline|not|null\?|number(?:->string|\?)|numerator|odd\?|open-(?:input|output)-(?:bytevector|string)|or|output-port(?:-open\?|\?)|pair\?|peek-char|peek-u8|port\?|positive\?|procedure\?|quotient|raise|raise-continuable|rational\?|rationalize|read-(?:bytevector|bytevector!|char|error\?|line|string|u8)|real\?|remainder|reverse|round|set-c[ad]r!|square|string(?:->list|->number|->symbol|->utf8|->vector|-append|-copy|-copy!|-fill!|-for-each|-length|-map|-ref|-set!|\?|<\?|<=\?|=\?|>\?|>=\?)?|substring|symbol(?:->string|\?|=\?)|syntax-error|textual-port\?|truncate(?:-quotient|-remainder|\/)?|u8-ready\?|utf8->string|values|vector(?:->list|->string|-append|-copy|-copy!|-fill!|-for-each|-length|-map|-ref|-set!|\?)?|with-exception-handler|write-(?:bytevector|char|string|u8)|zero\?)(?=[()\[\]\s]|$)/,lookbehind:!0},operator:{pattern:/((?:^|[^'`#])[(\[])(?:[-+*%/]|[<>]=?|=>?)(?=[()\[\]\s]|$)/,lookbehind:!0},number:{pattern:RegExp(function(e){for(var r in e)e[r]=e[r].replace(/<[\w\s]+>/g,(function(r){return"(?:"+e[r].trim()+")"}));return e[r]}({"":/\d+(?:\/\d+)|(?:\d+(?:\.\d*)?|\.\d+)(?:[esfdl][+-]?\d+)?/.source,"":/[+-]?|[+-](?:inf|nan)\.0/.source,"":/[+-](?:|(?:inf|nan)\.0)?i/.source,"":/(?:@|)?|/.source,"":/(?:#d(?:#[ei])?|#[ei](?:#d)?)?/.source,"":/[0-9a-f]+(?:\/[0-9a-f]+)?/.source,"":/[+-]?|[+-](?:inf|nan)\.0/.source,"":/[+-](?:|(?:inf|nan)\.0)?i/.source,"":/(?:@|)?|/.source,"":/#[box](?:#[ei])?|(?:#[ei])?#[box]/.source,"":/(^|[()\[\]\s])(?:|)(?=[()\[\]\s]|$)/.source}),"i"),lookbehind:!0},boolean:{pattern:/(^|[()\[\]\s])#(?:[ft]|false|true)(?=[()\[\]\s]|$)/,lookbehind:!0},function:{pattern:/((?:^|[^'`#])[(\[])(?:[^|()\[\]'\s]+|\|(?:[^\\|]|\\.)*\|)(?=[()\[\]\s]|$)/,lookbehind:!0},identifier:{pattern:/(^|[()\[\]\s])\|(?:[^\\|]|\\.)*\|(?=[()\[\]\s]|$)/,lookbehind:!0,greedy:!0},punctuation:/[()\[\]']/}}(e)}e.exports=r,r.displayName="scheme",r.aliases=[]},90367:(e,r,a)=>{a.d(r,{default:()=>n});var t=a(32918);const n=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90504.d340d9cc.chunk.js b/ydb/core/viewer/monitoring/static/js/90504.d340d9cc.chunk.js new file mode 100644 index 000000000000..43eee66ea7aa --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90504.d340d9cc.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90504],{69649:e=>{function t(e){e.languages.livescript={comment:[{pattern:/(^|[^\\])\/\*[\s\S]*?\*\//,lookbehind:!0},{pattern:/(^|[^\\])#.*/,lookbehind:!0}],"interpolated-string":{pattern:/(^|[^"])("""|")(?:\\[\s\S]|(?!\2)[^\\])*\2(?!")/,lookbehind:!0,greedy:!0,inside:{variable:{pattern:/(^|[^\\])#[a-z_](?:-?[a-z]|[\d_])*/m,lookbehind:!0},interpolation:{pattern:/(^|[^\\])#\{[^}]+\}/m,lookbehind:!0,inside:{"interpolation-punctuation":{pattern:/^#\{|\}$/,alias:"variable"}}},string:/[\s\S]+/}},string:[{pattern:/('''|')(?:\\[\s\S]|(?!\1)[^\\])*\1/,greedy:!0},{pattern:/<\[[\s\S]*?\]>/,greedy:!0},/\\[^\s,;\])}]+/],regex:[{pattern:/\/\/(?:\[[^\r\n\]]*\]|\\.|(?!\/\/)[^\\\[])+\/\/[gimyu]{0,5}/,greedy:!0,inside:{comment:{pattern:/(^|[^\\])#.*/,lookbehind:!0}}},{pattern:/\/(?:\[[^\r\n\]]*\]|\\.|[^/\\\r\n\[])+\/[gimyu]{0,5}/,greedy:!0}],keyword:{pattern:/(^|(?!-).)\b(?:break|case|catch|class|const|continue|default|do|else|extends|fallthrough|finally|for(?: ever)?|function|if|implements|it|let|loop|new|null|otherwise|own|return|super|switch|that|then|this|throw|try|unless|until|var|void|when|while|yield)(?!-)\b/m,lookbehind:!0},"keyword-operator":{pattern:/(^|[^-])\b(?:(?:delete|require|typeof)!|(?:and|by|delete|export|from|import(?: all)?|in|instanceof|is(?: not|nt)?|not|of|or|til|to|typeof|with|xor)(?!-)\b)/m,lookbehind:!0,alias:"operator"},boolean:{pattern:/(^|[^-])\b(?:false|no|off|on|true|yes)(?!-)\b/m,lookbehind:!0},argument:{pattern:/(^|(?!\.&\.)[^&])&(?!&)\d*/m,lookbehind:!0,alias:"variable"},number:/\b(?:\d+~[\da-z]+|\d[\d_]*(?:\.\d[\d_]*)?(?:[a-z]\w*)?)/i,identifier:/[a-z_](?:-?[a-z]|[\d_])*/i,operator:[{pattern:/( )\.(?= )/,lookbehind:!0},/\.(?:[=~]|\.\.?)|\.(?:[&|^]|<<|>>>?)\.|:(?:=|:=?)|&&|\|[|>]|<(?:<[>=?]?|-(?:->?|>)?|\+\+?|@@?|%%?|\*\*?|!(?:~?=|--?>|~?~>)?|~(?:~?>|=)?|==?|\^\^?|[\/?]/],punctuation:/[(){}\[\]|.,:;`]/},e.languages.livescript["interpolated-string"].inside.interpolation.inside.rest=e.languages.livescript}e.exports=t,t.displayName="livescript",t.aliases=[]},90504:(e,t,n)=>{n.d(t,{default:()=>o});var i=n(69649);const o=n.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90513.c6053ab5.chunk.js b/ydb/core/viewer/monitoring/static/js/90513.c6053ab5.chunk.js new file mode 100644 index 000000000000..4c1a986b5601 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90513.c6053ab5.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90513],{90513:function(e,n,u){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var u=n(e);function r(e){return e>9?r(e%10):e}function t(e,n,u){return e+" "+function(e,n){return 2===n?function(e){return{m:"v",b:"v",d:"z"}[e.charAt(0)]+e.substring(1)}(e):e}({mm:"munutenn",MM:"miz",dd:"devezh"}[u],e)}var _={name:"br",weekdays:"Sul_Lun_Meurzh_Merc\u02bcher_Yaou_Gwener_Sadorn".split("_"),months:"Genver_C\u02bchwevrer_Meurzh_Ebrel_Mae_Mezheven_Gouere_Eost_Gwengolo_Here_Du_Kerzu".split("_"),weekStart:1,weekdaysShort:"Sul_Lun_Meu_Mer_Yao_Gwe_Sad".split("_"),monthsShort:"Gen_C\u02bchwe_Meu_Ebr_Mae_Eve_Gou_Eos_Gwe_Her_Du_Ker".split("_"),weekdaysMin:"Su_Lu_Me_Mer_Ya_Gw_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"h[e]mm A",LTS:"h[e]mm:ss A",L:"DD/MM/YYYY",LL:"D [a viz] MMMM YYYY",LLL:"D [a viz] MMMM YYYY h[e]mm A",LLLL:"dddd, D [a viz] MMMM YYYY h[e]mm A"},relativeTime:{future:"a-benn %s",past:"%s \u02bczo",s:"un nebeud segondenno\xf9",m:"ur vunutenn",mm:t,h:"un eur",hh:"%d eur",d:"un devezh",dd:t,M:"ur miz",MM:t,y:"ur bloaz",yy:function(e){switch(r(e)){case 1:case 3:case 4:case 5:case 9:return e+" bloaz";default:return e+" vloaz"}}},meridiem:function(e){return e<12?"a.m.":"g.m."}};return u.default.locale(_,null,!0),_}(u(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90529.112c30e3.chunk.js b/ydb/core/viewer/monitoring/static/js/90529.112c30e3.chunk.js new file mode 100644 index 000000000000..489f5321ab06 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90529.112c30e3.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90529],{31012:e=>{function d(e){e.languages.neon={comment:{pattern:/#.*/,greedy:!0},datetime:{pattern:/(^|[[{(=:,\s])\d\d\d\d-\d\d?-\d\d?(?:(?:[Tt]| +)\d\d?:\d\d:\d\d(?:\.\d*)? *(?:Z|[-+]\d\d?(?::?\d\d)?)?)?(?=$|[\]}),\s])/,lookbehind:!0,alias:"number"},key:{pattern:/(^|[[{(,\s])[^,:=[\]{}()'"\s]+(?=\s*:(?:$|[\]}),\s])|\s*=)/,lookbehind:!0,alias:"atrule"},number:{pattern:/(^|[[{(=:,\s])[+-]?(?:0x[\da-fA-F]+|0o[0-7]+|0b[01]+|(?:\d+(?:\.\d*)?|\.?\d+)(?:[eE][+-]?\d+)?)(?=$|[\]}),:=\s])/,lookbehind:!0},boolean:{pattern:/(^|[[{(=:,\s])(?:false|no|true|yes)(?=$|[\]}),:=\s])/i,lookbehind:!0},null:{pattern:/(^|[[{(=:,\s])(?:null)(?=$|[\]}),:=\s])/i,lookbehind:!0,alias:"keyword"},string:{pattern:/(^|[[{(=:,\s])(?:('''|""")\r?\n(?:(?:[^\r\n]|\r?\n(?![\t ]*\2))*\r?\n)?[\t ]*\2|'[^'\r\n]*'|"(?:\\.|[^\\"\r\n])*")/,lookbehind:!0,greedy:!0},literal:{pattern:/(^|[[{(=:,\s])(?:[^#"',:=[\]{}()\s`-]|[:-][^"',=[\]{}()\s])(?:[^,:=\]})(\s]|:(?![\s,\]})]|$)|[ \t]+[^#,:=\]})(\s])*/,lookbehind:!0,alias:"string"},punctuation:/[,:=[\]{}()-]/}}e.exports=d,d.displayName="neon",d.aliases=[]},90529:(e,d,n)=>{n.d(d,{default:()=>t});var s=n(31012);const t=n.n(s)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/90628.e6a33d41.chunk.js b/ydb/core/viewer/monitoring/static/js/90628.e6a33d41.chunk.js new file mode 100644 index 000000000000..cf7cb1069af5 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/90628.e6a33d41.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[90628],{90628:function(u,t,e){u.exports=function(u){"use strict";function t(u){return u&&"object"==typeof u&&"default"in u?u:{default:u}}var e=t(u);function n(u,t,e,n){var i={s:"muutama sekunti",m:"minuutti",mm:"%d minuuttia",h:"tunti",hh:"%d tuntia",d:"p\xe4iv\xe4",dd:"%d p\xe4iv\xe4\xe4",M:"kuukausi",MM:"%d kuukautta",y:"vuosi",yy:"%d vuotta",numbers:"nolla_yksi_kaksi_kolme_nelj\xe4_viisi_kuusi_seitsem\xe4n_kahdeksan_yhdeks\xe4n".split("_")},a={s:"muutaman sekunnin",m:"minuutin",mm:"%d minuutin",h:"tunnin",hh:"%d tunnin",d:"p\xe4iv\xe4n",dd:"%d p\xe4iv\xe4n",M:"kuukauden",MM:"%d kuukauden",y:"vuoden",yy:"%d vuoden",numbers:"nollan_yhden_kahden_kolmen_nelj\xe4n_viiden_kuuden_seitsem\xe4n_kahdeksan_yhdeks\xe4n".split("_")},_=n&&!t?a:i,s=_[e];return u<10?s.replace("%d",_.numbers[u]):s.replace("%d",u)}var i={name:"fi",weekdays:"sunnuntai_maanantai_tiistai_keskiviikko_torstai_perjantai_lauantai".split("_"),weekdaysShort:"su_ma_ti_ke_to_pe_la".split("_"),weekdaysMin:"su_ma_ti_ke_to_pe_la".split("_"),months:"tammikuu_helmikuu_maaliskuu_huhtikuu_toukokuu_kes\xe4kuu_hein\xe4kuu_elokuu_syyskuu_lokakuu_marraskuu_joulukuu".split("_"),monthsShort:"tammi_helmi_maalis_huhti_touko_kes\xe4_hein\xe4_elo_syys_loka_marras_joulu".split("_"),ordinal:function(u){return u+"."},weekStart:1,yearStart:4,relativeTime:{future:"%s p\xe4\xe4st\xe4",past:"%s sitten",s:n,m:n,mm:n,h:n,hh:n,d:n,dd:n,M:n,MM:n,y:n,yy:n},formats:{LT:"HH.mm",LTS:"HH.mm.ss",L:"DD.MM.YYYY",LL:"D. MMMM[ta] YYYY",LLL:"D. MMMM[ta] YYYY, [klo] HH.mm",LLLL:"dddd, D. MMMM[ta] YYYY, [klo] HH.mm",l:"D.M.YYYY",ll:"D. MMM YYYY",lll:"D. MMM YYYY, [klo] HH.mm",llll:"ddd, D. MMM YYYY, [klo] HH.mm"}};return e.default.locale(i,null,!0),i}(e(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9067.254af4a9.chunk.js b/ydb/core/viewer/monitoring/static/js/9067.254af4a9.chunk.js deleted file mode 100644 index 50aecf6a0ada..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9067.254af4a9.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9067],{49067:function(a,e,i){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var i=e(a),_={name:"mi",weekdays:"R\u0101tapu_Mane_T\u016brei_Wenerei_T\u0101ite_Paraire_H\u0101tarei".split("_"),months:"Kohi-t\u0101te_Hui-tanguru_Pout\u016b-te-rangi_Paenga-wh\u0101wh\u0101_Haratua_Pipiri_H\u014dngoingoi_Here-turi-k\u014dk\u0101_Mahuru_Whiringa-\u0101-nuku_Whiringa-\u0101-rangi_Hakihea".split("_"),weekStart:1,weekdaysShort:"Ta_Ma_T\u016b_We_T\u0101i_Pa_H\u0101".split("_"),monthsShort:"Kohi_Hui_Pou_Pae_Hara_Pipi_H\u014dngoi_Here_Mahu_Whi-nu_Whi-ra_Haki".split("_"),weekdaysMin:"Ta_Ma_T\u016b_We_T\u0101i_Pa_H\u0101".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [i] HH:mm",LLLL:"dddd, D MMMM YYYY [i] HH:mm"},relativeTime:{future:"i roto i %s",past:"%s i mua",s:"te h\u0113kona ruarua",m:"he meneti",mm:"%d meneti",h:"te haora",hh:"%d haora",d:"he ra",dd:"%d ra",M:"he marama",MM:"%d marama",y:"he tau",yy:"%d tau"}};return i.default.locale(_,null,!0),_}(i(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/91087.3a776c06.chunk.js b/ydb/core/viewer/monitoring/static/js/91087.3a776c06.chunk.js new file mode 100644 index 000000000000..20be23c56c87 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/91087.3a776c06.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[91087],{5266:a=>{function n(a){a.languages.jsstacktrace={"error-message":{pattern:/^\S.*/m,alias:"string"},"stack-frame":{pattern:/(^[ \t]+)at[ \t].*/m,lookbehind:!0,inside:{"not-my-code":{pattern:/^at[ \t]+(?!\s)(?:node\.js||.*(?:node_modules|\(\)|\(|$|\(internal\/|\(node\.js)).*/m,alias:"comment"},filename:{pattern:/(\bat\s+(?!\s)|\()(?:[a-zA-Z]:)?[^():]+(?=:)/,lookbehind:!0,alias:"url"},function:{pattern:/(\bat\s+(?:new\s+)?)(?!\s)[_$a-zA-Z\xA0-\uFFFF<][.$\w\xA0-\uFFFF<>]*/,lookbehind:!0,inside:{punctuation:/\./}},punctuation:/[()]/,keyword:/\b(?:at|new)\b/,alias:{pattern:/\[(?:as\s+)?(?!\s)[_$a-zA-Z\xA0-\uFFFF][$\w\xA0-\uFFFF]*\]/,alias:"variable"},"line-number":{pattern:/:\d+(?::\d+)?\b/,alias:"number",inside:{punctuation:/:/}}}}}}a.exports=n,n.displayName="jsstacktrace",n.aliases=[]},91087:(a,n,e)=>{e.d(n,{default:()=>s});var t=e(5266);const s=e.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/91249.38e22793.chunk.js b/ydb/core/viewer/monitoring/static/js/91249.38e22793.chunk.js new file mode 100644 index 000000000000..17bed00f3869 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/91249.38e22793.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[91249],{33788:i=>{function a(i){i.languages.wiki=i.languages.extend("markup",{"block-comment":{pattern:/(^|[^\\])\/\*[\s\S]*?\*\//,lookbehind:!0,alias:"comment"},heading:{pattern:/^(=+)[^=\r\n].*?\1/m,inside:{punctuation:/^=+|=+$/,important:/.+/}},emphasis:{pattern:/('{2,5}).+?\1/,inside:{"bold-italic":{pattern:/(''''').+?(?=\1)/,lookbehind:!0,alias:["bold","italic"]},bold:{pattern:/(''')[^'](?:.*?[^'])?(?=\1)/,lookbehind:!0},italic:{pattern:/('')[^'](?:.*?[^'])?(?=\1)/,lookbehind:!0},punctuation:/^''+|''+$/}},hr:{pattern:/^-{4,}/m,alias:"punctuation"},url:[/ISBN +(?:97[89][ -]?)?(?:\d[ -]?){9}[\dx]\b|(?:PMID|RFC) +\d+/i,/\[\[.+?\]\]|\[.+?\]/],variable:[/__[A-Z]+__/,/\{{3}.+?\}{3}/,/\{\{.+?\}\}/],symbol:[/^#redirect/im,/~{3,5}/],"table-tag":{pattern:/((?:^|[|!])[|!])[^|\r\n]+\|(?!\|)/m,lookbehind:!0,inside:{"table-bar":{pattern:/\|$/,alias:"punctuation"},rest:i.languages.markup.tag.inside}},punctuation:/^(?:\{\||\|\}|\|-|[*#:;!|])|\|\||!!/m}),i.languages.insertBefore("wiki","tag",{nowiki:{pattern:/<(nowiki|pre|source)\b[^>]*>[\s\S]*?<\/\1>/i,inside:{tag:{pattern:/<(?:nowiki|pre|source)\b[^>]*>|<\/(?:nowiki|pre|source)>/i,inside:i.languages.markup.tag.inside}}}})}i.exports=a,a.displayName="wiki",a.aliases=[]},91249:(i,a,e)=>{e.d(a,{default:()=>t});var n=e(33788);const t=e.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/91545.080bf65f.chunk.js b/ydb/core/viewer/monitoring/static/js/91545.080bf65f.chunk.js new file mode 100644 index 000000000000..6bcd5ebdf7cf --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/91545.080bf65f.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[91545],{58464:e=>{function t(e){e.languages.gdscript={comment:/#.*/,string:{pattern:/@?(?:("|')(?:(?!\1)[^\n\\]|\\[\s\S])*\1(?!"|')|"""(?:[^\\]|\\[\s\S])*?""")/,greedy:!0},"class-name":{pattern:/(^(?:class|class_name|extends)[ \t]+|^export\([ \t]*|\bas[ \t]+|(?:\b(?:const|var)[ \t]|[,(])[ \t]*\w+[ \t]*:[ \t]*|->[ \t]*)[a-zA-Z_]\w*/m,lookbehind:!0},keyword:/\b(?:and|as|assert|break|breakpoint|class|class_name|const|continue|elif|else|enum|export|extends|for|func|if|in|is|master|mastersync|match|not|null|onready|or|pass|preload|puppet|puppetsync|remote|remotesync|return|self|setget|signal|static|tool|var|while|yield)\b/,function:/\b[a-z_]\w*(?=[ \t]*\()/i,variable:/\$\w+/,number:[/\b0b[01_]+\b|\b0x[\da-fA-F_]+\b|(?:\b\d[\d_]*(?:\.[\d_]*)?|\B\.[\d_]+)(?:e[+-]?[\d_]+)?\b/,/\b(?:INF|NAN|PI|TAU)\b/],constant:/\b[A-Z][A-Z_\d]*\b/,boolean:/\b(?:false|true)\b/,operator:/->|:=|&&|\|\||<<|>>|[-+*/%&|!<>=]=?|[~^]/,punctuation:/[.:,;()[\]{}]/}}e.exports=t,t.displayName="gdscript",t.aliases=[]},91545:(e,t,s)=>{s.d(t,{default:()=>n});var a=s(58464);const n=s.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9176.3f08336f.chunk.js b/ydb/core/viewer/monitoring/static/js/9176.3f08336f.chunk.js deleted file mode 100644 index d464a4b93698..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9176.3f08336f.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9176.3f08336f.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9176],{99176:(e,t,s)=>{s.r(t),s.d(t,{conf:()=>n,language:()=>i});var n={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\#\%\^\&\*\(\)\-\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\?\s]+)/g,comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"<",close:">"}],folding:{markers:{start:new RegExp("^\\s*//\\s*(?:(?:#?region\\b)|(?:))")}}},i={defaultToken:"",tokenPostfix:".java",keywords:["abstract","continue","for","new","switch","assert","default","goto","package","synchronized","boolean","do","if","private","this","break","double","implements","protected","throw","byte","else","import","public","throws","case","enum","instanceof","return","transient","catch","extends","int","short","try","char","final","interface","static","void","class","finally","long","strictfp","volatile","const","float","native","super","while","true","false","yield","record","sealed","non-sealed","permits"],operators:["=",">","<","!","~","?",":","==","<=",">=","!=","&&","||","++","--","+","-","*","/","&","|","^","%","<<",">>",">>>","+=","-=","*=","/=","&=","|=","^=","%=","<<=",">>=",">>>="],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/@\s*[a-zA-Z_\$][\w\$]*/,"annotation"],[/(@digits)[eE]([\-+]?(@digits))?[fFdD]?/,"number.float"],[/(@digits)\.(@digits)([eE][\-+]?(@digits))?[fFdD]?/,"number.float"],[/0[xX](@hexdigits)[Ll]?/,"number.hex"],[/0(@octaldigits)[Ll]?/,"number.octal"],[/0[bB](@binarydigits)[Ll]?/,"number.binary"],[/(@digits)[fFdD]/,"number.float"],[/(@digits)[lL]?/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"""/,"string","@multistring"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@javadoc"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],javadoc:[[/[^\/*]+/,"comment.doc"],[/\/\*/,"comment.doc.invalid"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]],multistring:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"""/,"string","@pop"],[/./,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9177.3b6d6de8.chunk.js b/ydb/core/viewer/monitoring/static/js/9177.3b6d6de8.chunk.js new file mode 100644 index 000000000000..9b64e14e4570 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/9177.3b6d6de8.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9177],{9177:(e,i,a)=>{a.d(i,{default:()=>t});var n=a(25735);const t=a.n(n)()},25735:e=>{function i(e){e.languages.makefile={comment:{pattern:/(^|[^\\])#(?:\\(?:\r\n|[\s\S])|[^\\\r\n])*/,lookbehind:!0},string:{pattern:/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0},"builtin-target":{pattern:/\.[A-Z][^:#=\s]+(?=\s*:(?!=))/,alias:"builtin"},target:{pattern:/^(?:[^:=\s]|[ \t]+(?![\s:]))+(?=\s*:(?!=))/m,alias:"symbol",inside:{variable:/\$+(?:(?!\$)[^(){}:#=\s]+|(?=[({]))/}},variable:/\$+(?:(?!\$)[^(){}:#=\s]+|\([@*%<^+?][DF]\)|(?=[({]))/,keyword:/-include\b|\b(?:define|else|endef|endif|export|ifn?def|ifn?eq|include|override|private|sinclude|undefine|unexport|vpath)\b/,function:{pattern:/(\()(?:abspath|addsuffix|and|basename|call|dir|error|eval|file|filter(?:-out)?|findstring|firstword|flavor|foreach|guile|if|info|join|lastword|load|notdir|or|origin|patsubst|realpath|shell|sort|strip|subst|suffix|value|warning|wildcard|word(?:list|s)?)(?=[ \t])/,lookbehind:!0},operator:/(?:::|[?:+!])?=|[|@]/,punctuation:/[:;(){}]/}}e.exports=i,i.displayName="makefile",i.aliases=[]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/91880.1a716d56.chunk.js b/ydb/core/viewer/monitoring/static/js/91880.1a716d56.chunk.js new file mode 100644 index 000000000000..66629f7e6d41 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/91880.1a716d56.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[91880],{72483:e=>{function t(e){e.languages.bro={comment:{pattern:/(^|[^\\$])#.*/,lookbehind:!0,inside:{italic:/\b(?:FIXME|TODO|XXX)\b/}},string:{pattern:/(["'])(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/,greedy:!0},boolean:/\b[TF]\b/,function:{pattern:/(\b(?:event|function|hook)[ \t]+)\w+(?:::\w+)?/,lookbehind:!0},builtin:/(?:@(?:load(?:-(?:plugin|sigs))?|unload|prefixes|ifn?def|else|(?:end)?if|DIR|FILENAME))|(?:&?(?:add_func|create_expire|default|delete_func|encrypt|error_handler|expire_func|group|log|mergeable|optional|persistent|priority|raw_output|read_expire|redef|rotate_interval|rotate_size|synchronized|type_column|write_expire))/,constant:{pattern:/(\bconst[ \t]+)\w+/i,lookbehind:!0},keyword:/\b(?:add|addr|alarm|any|bool|break|const|continue|count|delete|double|else|enum|event|export|file|for|function|global|hook|if|in|int|interval|local|module|next|of|opaque|pattern|port|print|record|return|schedule|set|string|subnet|table|time|timeout|using|vector|when)\b/,operator:/--?|\+\+?|!=?=?|<=?|>=?|==?=?|&&|\|\|?|\?|\*|\/|~|\^|%/,number:/\b0x[\da-f]+\b|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:e[+-]?\d+)?/i,punctuation:/[{}[\];(),.:]/}}e.exports=t,t.displayName="bro",t.aliases=[]},91880:(e,t,n)=>{n.d(t,{default:()=>r});var o=n(72483);const r=n.n(o)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92008.7d46cb66.chunk.js b/ydb/core/viewer/monitoring/static/js/92008.7d46cb66.chunk.js new file mode 100644 index 000000000000..5fb8a9a99bcc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92008.7d46cb66.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92008],{70533:d=>{function a(d){d.languages.nasm={comment:/;.*$/m,string:/(["'`])(?:\\.|(?!\1)[^\\\r\n])*\1/,label:{pattern:/(^\s*)[A-Za-z._?$][\w.?$@~#]*:/m,lookbehind:!0,alias:"function"},keyword:[/\[?BITS (?:16|32|64)\]?/,{pattern:/(^\s*)section\s*[a-z.]+:?/im,lookbehind:!0},/(?:extern|global)[^;\r\n]*/i,/(?:CPU|DEFAULT|FLOAT).*$/m],register:{pattern:/\b(?:st\d|[xyz]mm\d\d?|[cdt]r\d|r\d\d?[bwd]?|[er]?[abcd]x|[abcd][hl]|[er]?(?:bp|di|si|sp)|[cdefgs]s)\b/i,alias:"variable"},number:/(?:\b|(?=\$))(?:0[hx](?:\.[\da-f]+|[\da-f]+(?:\.[\da-f]+)?)(?:p[+-]?\d+)?|\d[\da-f]+[hx]|\$\d[\da-f]*|0[oq][0-7]+|[0-7]+[oq]|0[by][01]+|[01]+[by]|0[dt]\d+|(?:\d+(?:\.\d+)?|\.\d+)(?:\.?e[+-]?\d+)?[dt]?)\b/i,operator:/[\[\]*+\-\/%<>=&|$!]/}}d.exports=a,a.displayName="nasm",a.aliases=[]},92008:(d,a,e)=>{e.d(a,{default:()=>b});var s=e(70533);const b=e.n(s)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92016.1c9c5217.chunk.js b/ydb/core/viewer/monitoring/static/js/92016.1c9c5217.chunk.js new file mode 100644 index 000000000000..aada7732d15d --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92016.1c9c5217.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 92016.1c9c5217.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92016],{92016:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>r,language:()=>s});var r={comments:{lineComment:"#",blockComment:["=begin","=end"]},brackets:[["(",")"],["{","}"],["[","]"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],indentationRules:{increaseIndentPattern:new RegExp("^\\s*((begin|class|(private|protected)\\s+def|def|else|elsif|ensure|for|if|module|rescue|unless|until|when|while|case)|([^#]*\\sdo\\b)|([^#]*=\\s*(case|if|unless)))\\b([^#\\{;]|(\"|'|/).*\\4)*(#.*)?$"),decreaseIndentPattern:new RegExp("^\\s*([}\\]]([,)]?\\s*(#|$)|\\.[a-zA-Z_]\\w*\\b)|(end|rescue|ensure|else|elsif|when)\\b)")}},s={tokenPostfix:".ruby",keywords:["__LINE__","__ENCODING__","__FILE__","BEGIN","END","alias","and","begin","break","case","class","def","defined?","do","else","elsif","end","ensure","for","false","if","in","module","next","nil","not","or","redo","rescue","retry","return","self","super","then","true","undef","unless","until","when","while","yield"],keywordops:["::","..","...","?",":","=>"],builtins:["require","public","private","include","extend","attr_reader","protected","private_class_method","protected_class_method","new"],declarations:["module","class","def","case","do","begin","for","if","while","until","unless"],linedecls:["def","case","do","begin","for","if","while","until","unless"],operators:["^","&","|","<=>","==","===","!~","=~",">",">=","<","<=","<<",">>","+","-","*","/","%","**","~","+@","-@","[]","[]=","`","+=","-=","*=","**=","/=","^=","%=","<<=",">>=","&=","&&=","||=","|="],brackets:[{open:"(",close:")",token:"delimiter.parenthesis"},{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"}],symbols:/[=>"}],[/%([qws])(@delim)/,{token:"string.$1.delim",switchTo:"@qstring.$1.$2.$2"}],[/%r\(/,{token:"regexp.delim",switchTo:"@pregexp.(.)"}],[/%r\[/,{token:"regexp.delim",switchTo:"@pregexp.[.]"}],[/%r\{/,{token:"regexp.delim",switchTo:"@pregexp.{.}"}],[/%r"}],[/%r(@delim)/,{token:"regexp.delim",switchTo:"@pregexp.$1.$1"}],[/%(x|W|Q?)\(/,{token:"string.$1.delim",switchTo:"@qqstring.$1.(.)"}],[/%(x|W|Q?)\[/,{token:"string.$1.delim",switchTo:"@qqstring.$1.[.]"}],[/%(x|W|Q?)\{/,{token:"string.$1.delim",switchTo:"@qqstring.$1.{.}"}],[/%(x|W|Q?)"}],[/%(x|W|Q?)(@delim)/,{token:"string.$1.delim",switchTo:"@qqstring.$1.$2.$2"}],[/%([rqwsxW]|Q?)./,{token:"invalid",next:"@pop"}],[/./,{token:"invalid",next:"@pop"}]],qstring:[[/\\$/,"string.$S2.escape"],[/\\./,"string.$S2.escape"],[/./,{cases:{"$#==$S4":{token:"string.$S2.delim",next:"@pop"},"$#==$S3":{token:"string.$S2.delim",next:"@push"},"@default":"string.$S2"}}]],qqstring:[[/#/,"string.$S2.escape","@interpolated"],{include:"@qstring"}],whitespace:[[/[ \t\r\n]+/,""],[/^\s*=begin\b/,"comment","@comment"],[/#.*$/,"comment"]],comment:[[/[^=]+/,"comment"],[/^\s*=begin\b/,"comment.invalid"],[/^\s*=end\b.*/,"comment","@pop"],[/[=]/,"comment"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9312.5eb8d4b1.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/92016.1c9c5217.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/9312.5eb8d4b1.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/92016.1c9c5217.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/921.0402e36c.chunk.js b/ydb/core/viewer/monitoring/static/js/921.0402e36c.chunk.js deleted file mode 100644 index 86862b621206..000000000000 --- a/ydb/core/viewer/monitoring/static/js/921.0402e36c.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[921],{80921:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"si",weekdays:"\u0d89\u0dbb\u0dd2\u0daf\u0dcf_\u0dc3\u0db3\u0dd4\u0daf\u0dcf_\u0d85\u0d9f\u0dc4\u0dbb\u0dd4\u0dc0\u0dcf\u0daf\u0dcf_\u0db6\u0daf\u0dcf\u0daf\u0dcf_\u0db6\u0dca\u200d\u0dbb\u0dc4\u0dc3\u0dca\u0db4\u0dad\u0dd2\u0db1\u0dca\u0daf\u0dcf_\u0dc3\u0dd2\u0d9a\u0dd4\u0dbb\u0dcf\u0daf\u0dcf_\u0dc3\u0dd9\u0db1\u0dc3\u0dd4\u0dbb\u0dcf\u0daf\u0dcf".split("_"),months:"\u0daf\u0dd4\u0dbb\u0dd4\u0dad\u0dd4_\u0db1\u0dc0\u0db8\u0dca_\u0db8\u0dd0\u0daf\u0dd2\u0db1\u0dca_\u0db6\u0d9a\u0dca_\u0dc0\u0dd9\u0dc3\u0d9a\u0dca_\u0db4\u0ddc\u0dc3\u0ddc\u0db1\u0dca_\u0d87\u0dc3\u0dc5_\u0db1\u0dd2\u0d9a\u0dd2\u0dab\u0dd2_\u0db6\u0dd2\u0db1\u0dbb_\u0dc0\u0db4\u0dca_\u0d89\u0dbd\u0dca_\u0d8b\u0db3\u0dd4\u0dc0\u0db4\u0dca".split("_"),weekdaysShort:"\u0d89\u0dbb\u0dd2_\u0dc3\u0db3\u0dd4_\u0d85\u0d9f_\u0db6\u0daf\u0dcf_\u0db6\u0dca\u200d\u0dbb\u0dc4_\u0dc3\u0dd2\u0d9a\u0dd4_\u0dc3\u0dd9\u0db1".split("_"),monthsShort:"\u0daf\u0dd4\u0dbb\u0dd4_\u0db1\u0dc0_\u0db8\u0dd0\u0daf\u0dd2_\u0db6\u0d9a\u0dca_\u0dc0\u0dd9\u0dc3_\u0db4\u0ddc\u0dc3\u0ddc_\u0d87\u0dc3_\u0db1\u0dd2\u0d9a\u0dd2_\u0db6\u0dd2\u0db1_\u0dc0\u0db4\u0dca_\u0d89\u0dbd\u0dca_\u0d8b\u0db3\u0dd4".split("_"),weekdaysMin:"\u0d89_\u0dc3_\u0d85_\u0db6_\u0db6\u0dca\u200d\u0dbb_\u0dc3\u0dd2_\u0dc3\u0dd9".split("_"),ordinal:function(_){return _},formats:{LT:"a h:mm",LTS:"a h:mm:ss",L:"YYYY/MM/DD",LL:"YYYY MMMM D",LLL:"YYYY MMMM D, a h:mm",LLLL:"YYYY MMMM D [\u0dc0\u0dd0\u0db1\u0dd2] dddd, a h:mm:ss"},relativeTime:{future:"%s\u0d9a\u0dd2\u0db1\u0dca",past:"%s\u0d9a\u0da7 \u0db4\u0dd9\u0dbb",s:"\u0dad\u0dad\u0dca\u0db4\u0dbb \u0d9a\u0dd2\u0dc4\u0dd2\u0db4\u0dba",m:"\u0dc0\u0dd2\u0db1\u0dcf\u0da9\u0dd2\u0dba",mm:"\u0dc0\u0dd2\u0db1\u0dcf\u0da9\u0dd2 %d",h:"\u0db4\u0dd0\u0dba",hh:"\u0db4\u0dd0\u0dba %d",d:"\u0daf\u0dd2\u0db1\u0dba",dd:"\u0daf\u0dd2\u0db1 %d",M:"\u0db8\u0dcf\u0dc3\u0dba",MM:"\u0db8\u0dcf\u0dc3 %d",y:"\u0dc0\u0dc3\u0dbb",yy:"\u0dc0\u0dc3\u0dbb %d"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9220.a9f48eb9.chunk.js b/ydb/core/viewer/monitoring/static/js/9220.a9f48eb9.chunk.js deleted file mode 100644 index e39a87e48e81..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9220.a9f48eb9.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9220],{46839:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),t={name:"sv",weekdays:"s\xf6ndag_m\xe5ndag_tisdag_onsdag_torsdag_fredag_l\xf6rdag".split("_"),weekdaysShort:"s\xf6n_m\xe5n_tis_ons_tor_fre_l\xf6r".split("_"),weekdaysMin:"s\xf6_m\xe5_ti_on_to_fr_l\xf6".split("_"),months:"januari_februari_mars_april_maj_juni_juli_augusti_september_oktober_november_december".split("_"),monthsShort:"jan_feb_mar_apr_maj_jun_jul_aug_sep_okt_nov_dec".split("_"),weekStart:1,yearStart:4,ordinal:function(e){var a=e%10;return"["+e+(1===a||2===a?"a":"e")+"]"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"YYYY-MM-DD",LL:"D MMMM YYYY",LLL:"D MMMM YYYY [kl.] HH:mm",LLLL:"dddd D MMMM YYYY [kl.] HH:mm",lll:"D MMM YYYY HH:mm",llll:"ddd D MMM YYYY HH:mm"},relativeTime:{future:"om %s",past:"f\xf6r %s sedan",s:"n\xe5gra sekunder",m:"en minut",mm:"%d minuter",h:"en timme",hh:"%d timmar",d:"en dag",dd:"%d dagar",M:"en m\xe5nad",MM:"%d m\xe5nader",y:"ett \xe5r",yy:"%d \xe5r"}};return _.default.locale(t,null,!0),t}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9222.a1913f85.chunk.js b/ydb/core/viewer/monitoring/static/js/9222.a1913f85.chunk.js deleted file mode 100644 index 73c190e543ab..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9222.a1913f85.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9222],{89222:function(e,a,_){e.exports=function(e){"use strict";function a(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=a(e),n={name:"af",weekdays:"Sondag_Maandag_Dinsdag_Woensdag_Donderdag_Vrydag_Saterdag".split("_"),months:"Januarie_Februarie_Maart_April_Mei_Junie_Julie_Augustus_September_Oktober_November_Desember".split("_"),weekStart:1,weekdaysShort:"Son_Maa_Din_Woe_Don_Vry_Sat".split("_"),monthsShort:"Jan_Feb_Mrt_Apr_Mei_Jun_Jul_Aug_Sep_Okt_Nov_Des".split("_"),weekdaysMin:"So_Ma_Di_Wo_Do_Vr_Sa".split("_"),ordinal:function(e){return e},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"oor %s",past:"%s gelede",s:"'n paar sekondes",m:"'n minuut",mm:"%d minute",h:"'n uur",hh:"%d ure",d:"'n dag",dd:"%d dae",M:"'n maand",MM:"%d maande",y:"'n jaar",yy:"%d jaar"}};return _.default.locale(n,null,!0),n}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92412.ebe2fa11.chunk.js b/ydb/core/viewer/monitoring/static/js/92412.ebe2fa11.chunk.js new file mode 100644 index 000000000000..a91c4251f774 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92412.ebe2fa11.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92412],{3685:(e,s,t)=>{t.d(s,{$:()=>o});var n=t(54090),l=t(77506),a=t(33775),i=t(60712);const r=(0,l.cn)("ydb-entity-page-title");function o({entityName:e,status:s=n.m.Grey,id:t,className:l}){return(0,i.jsxs)("div",{className:r(null,l),children:[(0,i.jsx)("span",{className:r("prefix"),children:e}),(0,i.jsx)(a.k,{className:r("icon"),status:s,size:"s"}),t]})}},18677:(e,s,t)=>{t.d(s,{A:()=>l});var n=t(59284);const l=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},22983:(e,s,t)=>{t.d(s,{B:()=>c});var n=t(59284),l=t(84476),a=t(84375),i=t(55974),r=t(42829),o=t(60712);function c({children:e,onConfirmAction:s,onConfirmActionSuccess:t,dialogHeader:c,dialogText:d,retryButtonText:u,buttonDisabled:v=!1,buttonView:h="action",buttonTitle:m,buttonClassName:p,withPopover:x=!1,popoverContent:f,popoverPlacement:g="right",popoverDisabled:b=!0}){const[j,y]=n.useState(!1),[N,w]=n.useState(!1),[k,S]=n.useState(!1),C=()=>(0,o.jsx)(l.$,{onClick:()=>y(!0),view:h,disabled:v,loading:!v&&N,className:p,title:m,children:e});return(0,o.jsxs)(n.Fragment,{children:[(0,o.jsx)(i.g,{visible:j,header:c,text:d,withRetry:k,retryButtonText:u,onConfirm:async e=>{w(!0),await s(e)},onConfirmActionSuccess:async()=>{S(!1);try{await(null===t||void 0===t?void 0:t())}finally{w(!1)}},onConfirmActionError:e=>{S((0,r.D)(e)),w(!1)},onClose:()=>{y(!1)}}),x?(0,o.jsx)(a.A,{content:f,placement:g,disabled:b,children:C()}):C()]})}},42655:(e,s,t)=>{t.d(s,{y:()=>d});var n=t(59284),l=t(89169),a=t(77506),i=t(66781),r=t(60712);const o=(0,a.cn)("ydb-info-viewer-skeleton"),c=()=>(0,r.jsxs)("div",{className:o("label"),children:[(0,r.jsx)(l.E,{className:o("label__text")}),(0,r.jsx)("div",{className:o("label__dots")})]}),d=({rows:e=8,className:s,delay:t=600})=>{const[a]=(0,i.y)(t);let d=(0,r.jsxs)(n.Fragment,{children:[(0,r.jsx)(c,{}),(0,r.jsx)(l.E,{className:o("value")})]});return a||(d=null),(0,r.jsx)("div",{className:o(null,s),children:[...new Array(e)].map(((e,s)=>(0,r.jsx)("div",{className:o("row"),children:d},`skeleton-row-${s}`)))})}},42829:(e,s,t)=>{t.d(s,{D:()=>n});const n=e=>Boolean(e&&"object"===typeof e&&"retryPossible"in e&&e.retryPossible)},55974:(e,s,t)=>{t.d(s,{g:()=>g});var n=t(59284),l=t(18677),a=t(71153),i=t(74321),r=t(2198),o=t(99991),c=t(56999),d=t(77506),u=t(81288),v=t(48372);const h=JSON.parse('{"default-error":"Something went wrong, action cannot be completed","no-rights-error":"You don\'t have enough rights to complete the operation","button-confirm":"Confirm","button-retry":"Retry","button-cancel":"Cancel","button-close":"Close","checkbox-text":"I understand what I\'m doing"}'),m=(0,v.g4)("ydb-critical-action-dialog",{en:h});var p=t(60712);const x=(0,d.cn)("ydb-critical-dialog"),f=e=>{if((0,u.cH)(e)){if(403===e.status)return m("no-rights-error");if("string"===typeof e.data)return e.data;if((0,u._E)(e)&&e.data)return(0,p.jsx)(c.O,{hideSeverity:!0,data:e.data});if(e.statusText)return e.statusText}return m("default-error")};function g({visible:e,header:s,text:t,withRetry:c,retryButtonText:d,withCheckBox:u,onClose:v,onConfirm:h,onConfirmActionSuccess:g,onConfirmActionError:b}){const[j,y]=n.useState(!1),[N,w]=n.useState(),[k,S]=n.useState(!1),C=async e=>(y(!0),h(e).then((()=>{g(),v()})).catch((e=>{b(e),w(e)})).finally((()=>{y(!1)})));return(0,p.jsx)(r.l,{open:e,hasCloseButton:!1,className:x(),size:"s",onClose:v,onTransitionExited:()=>{w(void 0),S(!1)},children:N?(0,p.jsxs)(n.Fragment,{children:[(0,p.jsx)(r.l.Header,{caption:s}),(0,p.jsx)(r.l.Body,{className:x("body"),children:(0,p.jsxs)("div",{className:x("body-message",{error:!0}),children:[(0,p.jsx)("span",{className:x("error-icon"),children:(0,p.jsx)(l.A,{width:"24",height:"22"})}),f(N)]})}),(0,p.jsx)(r.l.Footer,{loading:!1,preset:"default",textButtonApply:c?d||m("button-retry"):void 0,textButtonCancel:m("button-close"),onClickButtonApply:()=>C(!0),onClickButtonCancel:v})]}):(0,p.jsxs)(n.Fragment,{children:[(0,p.jsx)(r.l.Header,{caption:s}),(0,p.jsxs)(r.l.Body,{className:x("body"),children:[(0,p.jsxs)("div",{className:x("body-message",{warning:!0}),children:[(0,p.jsx)("span",{className:x("warning-icon"),children:(0,p.jsx)(o.I,{data:a.A,size:24})}),t]}),u?(0,p.jsx)(i.S,{checked:k,onUpdate:S,children:m("checkbox-text")}):null]}),(0,p.jsx)(r.l.Footer,{loading:j,preset:"default",textButtonApply:m("button-confirm"),textButtonCancel:m("button-cancel"),propsButtonApply:{type:"submit",disabled:u&&!k},onClickButtonCancel:v,onClickButtonApply:()=>C()})]})})}},56999:(e,s,t)=>{t.d(s,{O:()=>y});var n=t(59284),l=t(45720),a=t(16929),i=t(71153),r=t(18677),o=t(84476),c=t(33705),d=t(67884),u=t(99991),v=t(74529),h=t(77506),m=t(41650);const p=["S_FATAL","S_ERROR","S_WARNING","S_INFO"];function x(e){return function(e){return!!e&&void 0!==p[e]}(e)?p[e]:"S_INFO"}var f=t(60712);const g=(0,h.cn)("kv-result-issues"),b=(0,h.cn)("kv-issues"),j=(0,h.cn)("kv-issue");function y({data:e,hideSeverity:s}){const[t,l]=n.useState(!1),a="string"===typeof e||null===e||void 0===e?void 0:e.issues,i=Array.isArray(a)&&a.length>0;return(0,f.jsxs)("div",{className:g(),children:[(0,f.jsxs)("div",{className:g("error-message"),children:[(()=>{let t;if("string"===typeof e)t=e;else{var l,a;const i=x(null===e||void 0===e||null===(l=e.error)||void 0===l?void 0:l.severity);t=(0,f.jsxs)(n.Fragment,{children:[s?null:(0,f.jsxs)(n.Fragment,{children:[(0,f.jsx)(_,{severity:i})," "]}),(0,f.jsx)("span",{className:g("error-message-text"),children:null===e||void 0===e||null===(a=e.error)||void 0===a?void 0:a.message})]})}return t})(),i&&(0,f.jsx)(o.$,{view:"normal",onClick:()=>l(!t),children:t?"Hide details":"Show details"})]}),i&&t&&(0,f.jsx)(N,{hideSeverity:s,issues:a})]})}function N({issues:e,hideSeverity:s}){const t=null===e||void 0===e?void 0:e.reduce(((e,s)=>{var t;const n=null!==(t=s.severity)&&void 0!==t?t:10;return Math.min(e,n)}),10);return(0,f.jsx)("div",{className:b(null),children:null===e||void 0===e?void 0:e.map(((e,n)=>(0,f.jsx)(w,{hideSeverity:s,issue:e,expanded:e===t},n)))})}function w({issue:e,hideSeverity:s,level:t=0}){const[l,a]=n.useState(!0),i=x(e.severity),r=e.issues,d=Array.isArray(r)&&r.length>0,u=l?"bottom":"right";return(0,f.jsxs)("div",{className:j({leaf:!d,"has-issues":d}),children:[(0,f.jsxs)("div",{className:j("line"),children:[d&&(0,f.jsx)(o.$,{view:"flat-secondary",onClick:()=>a(!l),className:j("arrow-toggle"),children:(0,f.jsx)(c.I,{direction:u,size:16})}),s?null:(0,f.jsx)(_,{severity:i}),(0,f.jsx)(k,{issue:e}),e.issue_code?(0,f.jsxs)("span",{className:j("code"),children:["Code: ",e.issue_code]}):null]}),d&&l&&(0,f.jsx)("div",{className:j("issues"),children:(0,f.jsx)(S,{issues:r,level:t+1,expanded:l})})]})}function k({issue:e}){var s;const t=function(e){const{position:s}=e;if("object"!==typeof s||null===s||!(0,m.kf)(s.row))return"";const{row:t,column:n}=s;return(0,m.kf)(n)?`${t}:${n}`:`line ${t}`}(e),n=window.ydbEditor,l=()=>(0,f.jsxs)("span",{className:j("message"),children:[t&&(0,f.jsx)("span",{className:j("place-text"),title:"Position",children:t}),(0,f.jsx)("div",{className:j("message-text"),children:(0,f.jsx)(v.A,{value:e.message,expandLabel:"Show full message"})})]}),{row:a,column:i}=null!==(s=e.position)&&void 0!==s?s:{};if(!((0,m.kf)(a)&&n))return l();return(0,f.jsx)(d.N,{href:"#",extraProps:{draggable:!1},onClick:()=>{const e={lineNumber:a,column:null!==i&&void 0!==i?i:0};n.setPosition(e),n.revealPositionInCenterIfOutsideViewport(e),n.focus()},view:"primary",children:l()})}function S(e){const{issues:s,level:t,expanded:n}=e;return(0,f.jsx)("div",{className:j("list"),children:s.map(((e,s)=>(0,f.jsx)(w,{issue:e,level:t,expanded:n},s)))})}const C={S_INFO:l.A,S_WARNING:a.A,S_ERROR:i.A,S_FATAL:r.A},A=(0,h.cn)("yql-issue-severity");function _({severity:e}){const s=e.slice(2).toLowerCase();return(0,f.jsxs)("span",{className:A({severity:s}),children:[(0,f.jsx)(u.I,{className:A("icon"),data:C[e]}),(0,f.jsx)("span",{className:A("title"),children:s})]})}},58389:(e,s,t)=>{t.d(s,{B:()=>u});var n=t(87184),l=t(77506),a=t(90053),i=t(70043),r=t(60712);const o=(0,l.cn)("ydb-page-meta"),c="\xa0\xa0\xb7\xa0\xa0";function d({items:e,loading:s}){return(0,r.jsx)("div",{className:o("info"),children:s?(0,r.jsx)(i.E,{className:o("skeleton")}):e.filter((e=>Boolean(e))).join(c)})}function u({className:e,...s}){return(0,r.jsxs)(n.s,{gap:1,alignItems:"center",justifyContent:"space-between",className:o(null,e),children:[(0,r.jsx)(d,{...s}),(0,r.jsx)(a.E,{})]})}},67808:(e,s,t)=>{t.d(s,{E:()=>b});t(59284);var n=t(87184),l=t(92459),a=t(7435),i=t(77506),r=t(56839),o=t(31684),c=t(7187),d=t(12888),u=t(41650),v=t(60073),h=t(25196),m=t(15132),p=t(33775),x=t(39110),f=t(60712);const g=(0,i.cn)("ydb-vdisk-info");function b({data:e,withVDiskPageLink:s,withTitle:t,...i}){var c,g;const b=(0,d.X)(),{AllocatedSize:y,DiskSpace:N,FrontQueues:w,Guid:k,Replicated:S,VDiskState:C,VDiskSlotId:A,Kind:_,SatisfactionRank:E,AvailableSize:B,HasUnreadableBlobs:I,IncarnationGuid:R,InstanceGuid:F,StoragePoolName:O,ReadThroughput:L,WriteThroughput:z,PDiskId:T,NodeId:D}=e||{},P=[];var V,$;((0,a.f8)(A)&&P.push({label:(0,x.r)("slot-id"),value:A}),(0,a.f8)(O)&&P.push({label:(0,x.r)("pool-name"),value:O}),(0,a.f8)(C)&&P.push({label:(0,x.r)("state-status"),value:C}),Number(y)>=0&&Number(B)>=0&&P.push({label:(0,x.r)("size"),value:(0,f.jsx)(m.O,{value:y,capacity:Number(y)+Number(B),formatValues:r.vX,colorizeProgress:!0})}),(0,a.f8)(_)&&P.push({label:(0,x.r)("kind"),value:_}),(0,a.f8)(k)&&P.push({label:(0,x.r)("guid"),value:k}),(0,a.f8)(R)&&P.push({label:(0,x.r)("incarnation-guid"),value:R}),(0,a.f8)(F)&&P.push({label:(0,x.r)("instance-guid"),value:F}),(0,a.f8)(S)&&P.push({label:(0,x.r)("replication-status"),value:S?(0,x.r)("yes"):(0,x.r)("no")}),(0,a.f8)(N)&&P.push({label:(0,x.r)("space-status"),value:(0,f.jsx)(p.k,{status:N})}),(0,a.f8)(null===E||void 0===E||null===(c=E.FreshRank)||void 0===c?void 0:c.Flag))&&P.push({label:(0,x.r)("fresh-rank-satisfaction"),value:(0,f.jsx)(p.k,{status:null===E||void 0===E||null===(V=E.FreshRank)||void 0===V?void 0:V.Flag})});(0,a.f8)(null===E||void 0===E||null===(g=E.LevelRank)||void 0===g?void 0:g.Flag)&&P.push({label:(0,x.r)("level-rank-satisfaction"),value:(0,f.jsx)(p.k,{status:null===E||void 0===E||null===($=E.LevelRank)||void 0===$?void 0:$.Flag})});(0,a.f8)(w)&&P.push({label:(0,x.r)("front-queues"),value:(0,f.jsx)(p.k,{status:w})}),(0,a.f8)(I)&&P.push({label:(0,x.r)("has-unreadable-blobs"),value:I?(0,x.r)("yes"):(0,x.r)("no")}),(0,a.f8)(L)&&P.push({label:(0,x.r)("read-throughput"),value:(0,u.O4)(L)}),(0,a.f8)(z)&&P.push({label:(0,x.r)("write-throughput"),value:(0,u.O4)(z)});if((0,a.f8)(T)&&(0,a.f8)(D)&&(0,a.f8)(A)){const e=[];if(s){const s=(0,l.yX)({vDiskSlotId:A,pDiskId:T,nodeId:D});e.push((0,f.jsx)(h.K,{title:(0,x.r)("vdisk-page"),url:s,external:!1},s))}if(b){const s=(0,o.Wg)({nodeId:D,pDiskId:T,vDiskSlotId:A});e.push((0,f.jsx)(h.K,{title:(0,x.r)("developer-ui"),url:s},s))}e.length&&P.push({label:(0,x.r)("links"),value:(0,f.jsx)(n.s,{wrap:"wrap",gap:2,children:e})})}const H=e&&t?(0,f.jsx)(j,{data:e}):null;return(0,f.jsx)(v.z_,{info:P,title:H,...i})}function j({data:e}){return(0,f.jsxs)("div",{className:g("title"),children:[(0,x.r)("vdiks-title"),(0,f.jsx)(p.k,{status:(0,c.XY)(e.Severity)}),e.StringifiedId]})}},70043:(e,s,t)=>{t.d(s,{E:()=>i});var n=t(89169),l=t(66781),a=t(60712);const i=({delay:e=600,className:s})=>{const[t]=(0,l.y)(e);return t?(0,a.jsx)(n.E,{className:s}):null}},74321:(e,s,t)=>{t.d(s,{S:()=>c});var n=t(59284),l=t(64222),a=t(46898);function i(e){return n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 17 17",width:"16",height:"16",fill:"currentColor"},e),n.createElement("path",{d:"M4 7h9v3H4z"}))}function r(e){return n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 12 10",width:"16",height:"16",fill:"currentColor"},e),n.createElement("path",{d:"M.49 5.385l1.644-1.644 4.385 4.385L4.874 9.77.49 5.385zm4.384 1.096L10.356 1 12 2.644 6.519 8.126 4.874 6.48v.001z"}))}const o=(0,t(69220).om)("checkbox"),c=n.forwardRef((function(e,s){const{size:t="m",indeterminate:c,disabled:d=!1,content:u,children:v,title:h,style:m,className:p,qa:x}=e,{checked:f,inputProps:g}=(0,l.v)(e),b=u||v,j=n.createElement("span",{className:o("indicator")},n.createElement("span",{className:o("icon"),"aria-hidden":!0},c?n.createElement(i,{className:o("icon-svg",{type:"dash"})}):n.createElement(r,{className:o("icon-svg",{type:"tick"})})),n.createElement("input",Object.assign({},g,{className:o("control")})),n.createElement("span",{className:o("outline")}));return n.createElement(a.m,{ref:s,title:h,style:m,size:t,disabled:d,className:o({size:t,disabled:d,indeterminate:c,checked:f},p),qa:x,control:j},b)}))},74529:(e,s,t)=>{t.d(s,{A:()=>v});var n=t(59284),l=t(67884),a=t(77506),i=t(48372);const r=JSON.parse('{"default_collapse_label":"Show less","default_expand_label":"Show more","chars_count":[" ({{count}} symbol)"," ({{count}} symbols)"," ({{count}} symbols)"," ({{count}} symbols)"]}'),o=JSON.parse('{"default_collapse_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u043c\u0435\u043d\u044c\u0448\u0435","default_expand_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451","chars_count":[" ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u0430)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"," ({{count}} \u0441\u0438\u043c\u0432\u043e\u043b\u043e\u0432)"]}'),c=(0,i.g4)("ydb-shorty-string",{ru:o,en:r});var d=t(60712);const u=(0,a.cn)("kv-shorty-string");function v({value:e="",limit:s=200,strict:t=!1,displayLength:a=!0,render:i=e=>e,onToggle:r,expandLabel:o=c("default_expand_label"),collapseLabel:v=c("default_collapse_label")}){const[h,m]=n.useState(!1),p=(h?v:o)+(a&&!h?c("chars_count",{count:e.length}):""),x=e.length>s+(t?0:p.length),f=h||!x?e:e.slice(0,s-4)+"\xa0...";return(0,d.jsxs)("div",{className:u(),children:[i(f),x?(0,d.jsx)(l.N,{className:u("toggle"),href:"#",onClick:e=>{e.stopPropagation(),e.preventDefault(),m((e=>!e)),null===r||void 0===r||r()},children:p}):null]})}},79879:(e,s,t)=>{t.d(s,{A:()=>l});var n=t(59284);const l=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"m3.003 4.702 4.22-2.025a1.8 1.8 0 0 1 1.554 0l4.22 2.025a.89.89 0 0 1 .503.8V6a8.55 8.55 0 0 1-3.941 7.201l-.986.631a1.06 1.06 0 0 1-1.146 0l-.986-.63A8.55 8.55 0 0 1 2.5 6v-.498c0-.341.196-.652.503-.8m3.57-3.377L2.354 3.35A2.39 2.39 0 0 0 1 5.502V6a10.05 10.05 0 0 0 4.632 8.465l.986.63a2.56 2.56 0 0 0 2.764 0l.986-.63A10.05 10.05 0 0 0 15 6v-.498c0-.918-.526-1.755-1.354-2.152l-4.22-2.025a3.3 3.3 0 0 0-2.852 0M9.5 7a1.5 1.5 0 0 1-.75 1.3v1.95a.75.75 0 0 1-1.5 0V8.3A1.5 1.5 0 1 1 9.5 7",clipRule:"evenodd"}))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9243.cb95c73b.chunk.js b/ydb/core/viewer/monitoring/static/js/9243.cb95c73b.chunk.js deleted file mode 100644 index 30492fae920b..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9243.cb95c73b.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9243],{59243:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"am",weekdays:"\u12a5\u1211\u12f5_\u1230\u129e_\u121b\u12ad\u1230\u129e_\u1228\u1261\u12d5_\u1210\u1219\u1235_\u12a0\u122d\u1265_\u1245\u12f3\u121c".split("_"),weekdaysShort:"\u12a5\u1211\u12f5_\u1230\u129e_\u121b\u12ad\u1230_\u1228\u1261\u12d5_\u1210\u1219\u1235_\u12a0\u122d\u1265_\u1245\u12f3\u121c".split("_"),weekdaysMin:"\u12a5\u1211_\u1230\u129e_\u121b\u12ad_\u1228\u1261_\u1210\u1219_\u12a0\u122d_\u1245\u12f3".split("_"),months:"\u1303\u1295\u12cb\u122a_\u134c\u1265\u122f\u122a_\u121b\u122d\u127d_\u12a4\u1355\u122a\u120d_\u121c\u12ed_\u1301\u1295_\u1301\u120b\u12ed_\u12a6\u1308\u1235\u1275_\u1234\u1355\u1274\u121d\u1260\u122d_\u12a6\u12ad\u1276\u1260\u122d_\u1296\u126c\u121d\u1260\u122d_\u12f2\u1234\u121d\u1260\u122d".split("_"),monthsShort:"\u1303\u1295\u12cb_\u134c\u1265\u122f_\u121b\u122d\u127d_\u12a4\u1355\u122a_\u121c\u12ed_\u1301\u1295_\u1301\u120b\u12ed_\u12a6\u1308\u1235_\u1234\u1355\u1274_\u12a6\u12ad\u1276_\u1296\u126c\u121d_\u12f2\u1234\u121d".split("_"),weekStart:1,yearStart:4,relativeTime:{future:"\u1260%s",past:"%s \u1260\u134a\u1275",s:"\u1325\u1242\u1275 \u1230\u12a8\u1295\u12f6\u127d",m:"\u12a0\u1295\u12f5 \u12f0\u1242\u1243",mm:"%d \u12f0\u1242\u1243\u12ce\u127d",h:"\u12a0\u1295\u12f5 \u1230\u12d3\u1275",hh:"%d \u1230\u12d3\u1273\u1275",d:"\u12a0\u1295\u12f5 \u1240\u1295",dd:"%d \u1240\u1293\u1275",M:"\u12a0\u1295\u12f5 \u12c8\u122d",MM:"%d \u12c8\u122b\u1275",y:"\u12a0\u1295\u12f5 \u12d3\u1218\u1275",yy:"%d \u12d3\u1218\u1273\u1275"},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"MMMM D \u1363 YYYY",LLL:"MMMM D \u1363 YYYY HH:mm",LLLL:"dddd \u1363 MMMM D \u1363 YYYY HH:mm"},ordinal:function(_){return _+"\u129b"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92466.f38204fe.chunk.js b/ydb/core/viewer/monitoring/static/js/92466.f38204fe.chunk.js new file mode 100644 index 000000000000..2a1773aea8a8 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92466.f38204fe.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92466],{92466:function(e,o,_){e.exports=function(e){"use strict";function o(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var _=o(e),s={name:"gl",weekdays:"domingo_luns_martes_m\xe9rcores_xoves_venres_s\xe1bado".split("_"),months:"xaneiro_febreiro_marzo_abril_maio_xu\xf1o_xullo_agosto_setembro_outubro_novembro_decembro".split("_"),weekStart:1,weekdaysShort:"dom._lun._mar._m\xe9r._xov._ven._s\xe1b.".split("_"),monthsShort:"xan._feb._mar._abr._mai._xu\xf1._xul._ago._set._out._nov._dec.".split("_"),weekdaysMin:"do_lu_ma_m\xe9_xo_ve_s\xe1".split("_"),ordinal:function(e){return e+"\xba"},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY H:mm",LLLL:"dddd, D [de] MMMM [de] YYYY H:mm"},relativeTime:{future:"en %s",past:"fai %s",s:"uns segundos",m:"un minuto",mm:"%d minutos",h:"unha hora",hh:"%d horas",d:"un d\xeda",dd:"%d d\xedas",M:"un mes",MM:"%d meses",y:"un ano",yy:"%d anos"}};return _.default.locale(s,null,!0),s}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92551.088c5eb2.chunk.js b/ydb/core/viewer/monitoring/static/js/92551.088c5eb2.chunk.js new file mode 100644 index 000000000000..79a7511019ed --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92551.088c5eb2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92551],{91922:e=>{function t(e){e.languages.groovy=e.languages.extend("clike",{string:[{pattern:/("""|''')(?:[^\\]|\\[\s\S])*?\1|\$\/(?:[^/$]|\$(?:[/$]|(?![/$]))|\/(?!\$))*\/\$/,greedy:!0},{pattern:/(["'/])(?:\\.|(?!\1)[^\\\r\n])*\1/,greedy:!0}],keyword:/\b(?:abstract|as|assert|boolean|break|byte|case|catch|char|class|const|continue|def|default|do|double|else|enum|extends|final|finally|float|for|goto|if|implements|import|in|instanceof|int|interface|long|native|new|package|private|protected|public|return|short|static|strictfp|super|switch|synchronized|this|throw|throws|trait|transient|try|void|volatile|while)\b/,number:/\b(?:0b[01_]+|0x[\da-f_]+(?:\.[\da-f_p\-]+)?|[\d_]+(?:\.[\d_]+)?(?:e[+-]?\d+)?)[glidf]?\b/i,operator:{pattern:/(^|[^.])(?:~|==?~?|\?[.:]?|\*(?:[.=]|\*=?)?|\.[@&]|\.\.<|\.\.(?!\.)|-[-=>]?|\+[+=]?|!=?|<(?:<=?|=>?)?|>(?:>>?=?|=)?|&[&=]?|\|[|=]?|\/=?|\^=?|%=?)/,lookbehind:!0},punctuation:/\.+|[{}[\];(),:$]/}),e.languages.insertBefore("groovy","string",{shebang:{pattern:/#!.+/,alias:"comment"}}),e.languages.insertBefore("groovy","punctuation",{"spock-block":/\b(?:and|cleanup|expect|given|setup|then|when|where):/}),e.languages.insertBefore("groovy","function",{annotation:{pattern:/(^|[^.])@\w+/,lookbehind:!0,alias:"punctuation"}}),e.hooks.add("wrap",(function(t){if("groovy"===t.language&&"string"===t.type){var n=t.content.value[0];if("'"!=n){var a=/([^\\])(?:\$(?:\{.*?\}|[\w.]+))/;"$"===n&&(a=/([^\$])(?:\$(?:\{.*?\}|[\w.]+))/),t.content.value=t.content.value.replace(/</g,"<").replace(/&/g,"&"),t.content=e.highlight(t.content.value,{expression:{pattern:a,lookbehind:!0,inside:e.languages.groovy}}),t.classes.push("/"===n?"regex":"gstring")}}}))}e.exports=t,t.displayName="groovy",t.aliases=[]},92551:(e,t,n)=>{n.d(t,{default:()=>o});var a=n(91922);const o=n.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92816.26e23640.chunk.js b/ydb/core/viewer/monitoring/static/js/92816.26e23640.chunk.js new file mode 100644 index 000000000000..1bbf0913d83e --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92816.26e23640.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92816],{10165:e=>{function r(e){e.languages.parigp={comment:/\/\*[\s\S]*?\*\/|\\\\.*/,string:{pattern:/"(?:[^"\\\r\n]|\\.)*"/,greedy:!0},keyword:function(){var e=["breakpoint","break","dbg_down","dbg_err","dbg_up","dbg_x","forcomposite","fordiv","forell","forpart","forprime","forstep","forsubgroup","forvec","for","iferr","if","local","my","next","return","until","while"];return e=e.map((function(e){return e.split("").join(" *")})).join("|"),RegExp("\\b(?:"+e+")\\b")}(),function:/\b\w(?:[\w ]*\w)?(?= *\()/,number:{pattern:/((?:\. *\. *)?)(?:\b\d(?: *\d)*(?: *(?!\. *\.)\.(?: *\d)*)?|\. *\d(?: *\d)*)(?: *e *(?:[+-] *)?\d(?: *\d)*)?/i,lookbehind:!0},operator:/\. *\.|[*\/!](?: *=)?|%(?: *=|(?: *#)?(?: *')*)?|\+(?: *[+=])?|-(?: *[-=>])?|<(?: *>|(?: *<)?(?: *=)?)?|>(?: *>)?(?: *=)?|=(?: *=){0,2}|\\(?: *\/)?(?: *=)?|&(?: *&)?|\| *\||['#~^]/,punctuation:/[\[\]{}().,:;|]/}}e.exports=r,r.displayName="parigp",r.aliases=[]},92816:(e,r,o)=>{o.d(r,{default:()=>i});var n=o(10165);const i=o.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92868.fbd23d48.chunk.js b/ydb/core/viewer/monitoring/static/js/92868.fbd23d48.chunk.js new file mode 100644 index 000000000000..c9cf5711d656 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92868.fbd23d48.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92868],{33789:e=>{function t(e){e.languages.icon={comment:/#.*/,string:{pattern:/(["'])(?:(?!\1)[^\\\r\n_]|\\.|_(?!\1)(?:\r\n|[\s\S]))*\1/,greedy:!0},number:/\b(?:\d+r[a-z\d]+|\d+(?:\.\d+)?(?:e[+-]?\d+)?)\b|\.\d+\b/i,"builtin-keyword":{pattern:/&(?:allocated|ascii|clock|collections|cset|current|date|dateline|digits|dump|e|error(?:number|text|value)?|errout|fail|features|file|host|input|lcase|letters|level|line|main|null|output|phi|pi|pos|progname|random|regions|source|storage|subject|time|trace|ucase|version)\b/,alias:"variable"},directive:{pattern:/\$\w+/,alias:"builtin"},keyword:/\b(?:break|by|case|create|default|do|else|end|every|fail|global|if|initial|invocable|link|local|next|not|of|procedure|record|repeat|return|static|suspend|then|to|until|while)\b/,function:/\b(?!\d)\w+(?=\s*[({]|\s*!\s*\[)/,operator:/[+-]:(?!=)|(?:[\/?@^%&]|\+\+?|--?|==?=?|~==?=?|\*\*?|\|\|\|?|<(?:->?|>?=?)(?::=)?|:(?:=:?)?|[!.\\|~]/,punctuation:/[\[\](){},;]/}}e.exports=t,t.displayName="icon",t.aliases=[]},92868:(e,t,a)=>{a.d(t,{default:()=>n});var i=a(33789);const n=a.n(i)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/92984.bc3d29a6.chunk.js b/ydb/core/viewer/monitoring/static/js/92984.bc3d29a6.chunk.js new file mode 100644 index 000000000000..439485609cd0 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/92984.bc3d29a6.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[92984],{92984:function(_,d,t){_.exports=function(_){"use strict";function d(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=d(_),r={name:"x-pseudo",weekdays:"S~\xfa\xf1d\xe1~\xfd_M\xf3~\xf1d\xe1\xfd~_T\xfa\xe9~sd\xe1\xfd~_W\xe9d~\xf1\xe9sd~\xe1\xfd_T~h\xfars~d\xe1\xfd_~Fr\xedd~\xe1\xfd_S~\xe1t\xfar~d\xe1\xfd".split("_"),months:"J~\xe1\xf1\xfa\xe1~r\xfd_F~\xe9br\xfa~\xe1r\xfd_~M\xe1rc~h_\xc1p~r\xedl_~M\xe1\xfd_~J\xfa\xf1\xe9~_J\xfal~\xfd_\xc1\xfa~g\xfast~_S\xe9p~t\xe9mb~\xe9r_\xd3~ct\xf3b~\xe9r_\xd1~\xf3v\xe9m~b\xe9r_~D\xe9c\xe9~mb\xe9r".split("_"),weekStart:1,weekdaysShort:"S~\xfa\xf1_~M\xf3\xf1_~T\xfa\xe9_~W\xe9d_~Th\xfa_~Fr\xed_~S\xe1t".split("_"),monthsShort:"J~\xe1\xf1_~F\xe9b_~M\xe1r_~\xc1pr_~M\xe1\xfd_~J\xfa\xf1_~J\xfal_~\xc1\xfag_~S\xe9p_~\xd3ct_~\xd1\xf3v_~D\xe9c".split("_"),weekdaysMin:"S~\xfa_M\xf3~_T\xfa_~W\xe9_T~h_Fr~_S\xe1".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd, D MMMM YYYY HH:mm"},relativeTime:{future:"\xed~\xf1 %s",past:"%s \xe1~g\xf3",s:"\xe1 ~f\xe9w ~s\xe9c\xf3~\xf1ds",m:"\xe1 ~m\xed\xf1~\xfat\xe9",mm:"%d m~\xed\xf1\xfa~t\xe9s",h:"\xe1~\xf1 h\xf3~\xfar",hh:"%d h~\xf3\xfars",d:"\xe1 ~d\xe1\xfd",dd:"%d d~\xe1\xfds",M:"\xe1 ~m\xf3\xf1~th",MM:"%d m~\xf3\xf1t~hs",y:"\xe1 ~\xfd\xe9\xe1r",yy:"%d \xfd~\xe9\xe1rs"}};return t.default.locale(r,null,!0),r}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9300.277e4f3f.chunk.js b/ydb/core/viewer/monitoring/static/js/9300.277e4f3f.chunk.js deleted file mode 100644 index 68a1d7c5d8e1..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9300.277e4f3f.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9300],{2102:(e,t,r)=>{r.d(t,{A:()=>n});var a=r(77506),o=r(60712);const l=(0,a.cn)("ydb-diagnostic-card");function n({children:e,className:t,active:r,size:a="m",interactive:n=!0}){return(0,o.jsx)("div",{className:l({active:r,size:a,interactive:n},t),children:e})}},28539:(e,t,r)=>{r.d(t,{T:()=>a.T});var a=r(53755)},9252:(e,t,r)=>{r.d(t,{k:()=>n});var a=r(44433),o=r(88610),l=r(60712);const n=({value:e,onChange:t,className:r})=>(0,l.jsxs)(a.a,{value:e,onUpdate:t,className:r,children:[(0,l.jsx)(a.a.Option,{value:o.s$.ALL,children:o.s$.ALL}),(0,l.jsx)(a.a.Option,{value:o.s$.PROBLEMS,children:o.s$.PROBLEMS})]})},95963:(e,t,r)=>{r.d(t,{v:()=>a.v});var a=r(41775)},7117:(e,t,r)=>{r.d(t,{G:()=>Z});var a=r(59284),o=r(44508),l=r(98167),n=r(89073),s=r(86782),i=r(67028),u=r(15298),d=r(90182),p=r(88610);function c(){const e=(0,d.YQ)();return{problemFilter:(0,d.N4)(p.yV),handleProblemFilterChange:t=>{e((0,p.$u)(t))}}}var m=r(43951),h=r(78034),g=r(71708),y=r(62710),b=r(98089),f=r(69775),C=r(24555),v=r(28539),F=r(9252),N=r(95963),R=r(64934),x=r(44433),P=r(48372);const j=JSON.parse('{"nodes":"Nodes","empty.default":"No such nodes","no-nodes-groups":"No nodes groups","controls_search-placeholder":"Host name","controls_group-by-placeholder":"Group by:","controls_peer-role-label":"Peer role:","database":"database","static":"static","other":"other","any":"any"}'),S=(0,P.g4)("ydb-nodes",{en:j}),w=["database","static","other","any"],B={get database(){return S("database")},get static(){return S("static")},get other(){return S("other")},get any(){return S("any")}};var G=r(60712);function T({value:e="database",onChange:t}){return(0,G.jsx)(x.a,{value:e,onUpdate:t,children:w.map((e=>(0,G.jsx)(x.a.Option,{value:e,children:B[e]},e)))})}const I="nodesTableSelectedColumns",_=["NodeId","Host","Uptime","CPU","RAM","Version","Tablets"],E=["NodeId"],U=["SystemState","Host","DC","Rack","Database","Version","Uptime"];function A(e,t){return t?e:e.filter((e=>"SystemState"!==e))}var L=r(59109);const V=(0,r(77506).cn)("ydb-nodes"),k=e=>V("node",{unavailable:(0,h.X7)(e)}),O=e=>e&&403===e.status?(0,G.jsx)(L.O,{position:"left"}):(0,G.jsx)(o.o,{error:e});var q=r(67087);function D(e){var t;const[r,a]=(0,q.useQueryParams)({uptimeFilter:q.StringParam,peerRole:q.StringParam,search:q.StringParam,nodesGroupBy:q.StringParam}),o=h.Bm.parse(r.uptimeFilter),l=null!==(t=r.search)&&void 0!==t?t:"",n=(s=r.peerRole,w.find((e=>e===s)));var s;const u=(0,i.DM)(),d=function(e,t,r){return A(t,r).find((t=>t===e))}(r.nodesGroupBy,null!==e&&void 0!==e?e:[],u);return{uptimeFilter:o,searchValue:l,peerRoleFilter:n,groupByParam:d,handleSearchQueryChange:e=>{a({search:e||void 0},"replaceIn")},handleUptimeFilterChange:e=>{a({uptimeFilter:e},"replaceIn")},handlePeerRoleFilterChange:e=>{a({peerRole:e},"replaceIn")},handleGroupByParamChange:e=>{a({nodesGroupBy:e},"replaceIn")}}}function K({withGroupBySelect:e,groupByParams:t=[],withPeerRoleFilter:r,columnsToSelect:o,handleSelectedColumnsUpdate:l,entitiesCountCurrent:n,entitiesCountTotal:u,entitiesLoading:d}){const{searchValue:p,uptimeFilter:m,peerRoleFilter:h,groupByParam:g,handleSearchQueryChange:y,handleUptimeFilterChange:x,handlePeerRoleFilterChange:P,handleGroupByParamChange:j}=D(t),{problemFilter:w,handleProblemFilterChange:B}=c(),I=(0,i.DM)(),_=function(e,t){return A(e,t).map((e=>({value:e,content:(0,s.kn)(e)})))}(t,I),E=(0,i.WF)(),U=r&&E;return(0,G.jsxs)(a.Fragment,{children:[(0,G.jsx)(N.v,{onChange:y,placeholder:S("controls_search-placeholder"),width:238,value:p}),I&&e?null:(0,G.jsx)(F.k,{value:w,onChange:B}),e?null:(0,G.jsx)(R.j,{value:m,onChange:x}),U?(0,G.jsxs)(a.Fragment,{children:[(0,G.jsx)(b.E,{variant:"body-2",children:S("controls_peer-role-label")}),(0,G.jsx)(T,{value:h,onChange:P})]}):null,(0,G.jsx)(f.O,{popupWidth:200,items:o,showStatus:!0,onUpdate:l,sortable:!1}),e?(0,G.jsxs)(a.Fragment,{children:[(0,G.jsx)(b.E,{variant:"body-2",children:S("controls_group-by-placeholder")}),(0,G.jsx)(C.l,{hasClear:!0,placeholder:"-",width:150,defaultValue:g?[g]:void 0,onUpdate:e=>{j(e[0])},options:_,className:V("group-by-select"),popupClassName:V("group-by-popup")})]}):null,(0,G.jsx)(v.T,{current:n,total:u,label:S("nodes"),loading:d})]})}var M=r(78524),W=r(40427),Q=r(11906),$=r(69464),H=r(40781);const z=async e=>{const{type:t="any",storage:r=!1,tablets:a=!0,limit:o,offset:l,sortParams:n,filters:i,columnsIds:u}=e,{sortOrder:d,columnId:p}=null!==n&&void 0!==n?n:{},{path:c,database:m,searchValue:g,problemFilter:y,uptimeFilter:b,peerRoleFilter:f,filterGroup:C,filterGroupBy:v}=null!==i&&void 0!==i?i:{},F=(0,s.kU)(p),N=F?(0,$.T)(F,d):void 0,R=(0,H.R)(u,s.fN),x=await window.api.viewer.getNodes({type:t,storage:r,tablets:a,limit:o,offset:l,sort:N,path:c,database:m,filter:g,problems_only:(0,h.AB)(y),uptime:(0,h.Fo)(b),filter_peer_role:f,filter_group:C,filter_group_by:v,fieldsRequired:R}),P=(0,Q.N)(x);return{data:P.Nodes||[],found:P.FoundNodes||0,total:P.TotalNodes||0}};function X({path:e,database:t,searchValue:r,problemFilter:o,uptimeFilter:l,peerRoleFilter:n,filterGroup:i,filterGroupBy:u,columns:d,parentRef:p,renderControls:c,initialEntitiesCount:m}){const g=a.useMemo((()=>({path:e,database:t,searchValue:r,problemFilter:o,uptimeFilter:l,peerRoleFilter:n,filterGroup:i,filterGroupBy:u})),[e,t,r,o,l,n,i,u]);return(0,G.jsx)(W.k5,{columnsWidthLSKey:s.zO,parentRef:p,columns:d,fetchData:z,limit:50,initialEntitiesCount:m,renderControls:c,renderErrorMessage:O,renderEmptyDataMessage:()=>"All"!==o||l!==h.cW.All?(0,G.jsx)(M.v,{name:"thumbsUp",width:"200"}):S("empty.default"),getRowClassName:k,filters:g,tableName:"nodes"})}var Y=r(78762);function J(e){return[(0,Y._E)(),(0,Y.Nh)(e),(0,Y.eT)(),(0,Y.uk)(),(0,Y.OX)(),(0,Y.jl)(),(0,Y.fr)(),(0,Y.kv)(),(0,Y.pH)(),(0,Y.iX)(),(0,Y.ID)(),(0,Y.Rn)(),(0,Y.qp)(e)].map((e=>({...e,sortable:(0,s.sp)(e.name)})))}function Z({path:e,database:t,parentRef:r,additionalNodesProps:o,withPeerRoleFilter:n,columns:s=J({database:t,getNodeRef:null===o||void 0===o?void 0:o.getNodeRef}),defaultColumnsIds:u=_,requiredColumnsIds:d=E,selectedColumnsKey:p=I,groupByParams:m=U}){const{uptimeFilter:g,groupByParam:y,handleUptimeFilterChange:b}=D(m),{problemFilter:f,handleProblemFilterChange:C}=c(),v=(0,i.Pm)(),F=(0,i.Ye)();a.useEffect((()=>{!F||"All"===f&&g===h.cW.All||(C("All"),b(h.cW.All))}),[C,b,f,g,F]);return(0,G.jsx)(l.r,{loading:!v,children:F&&y?(0,G.jsx)(te,{path:e,database:t,parentRef:r,withPeerRoleFilter:n,columns:s,defaultColumnsIds:u,requiredColumnsIds:d,selectedColumnsKey:p,groupByParams:m}):(0,G.jsx)(ee,{path:e,database:t,parentRef:r,withPeerRoleFilter:n,columns:s,defaultColumnsIds:u,requiredColumnsIds:d,selectedColumnsKey:p,groupByParams:m})})}function ee({path:e,database:t,parentRef:r,withPeerRoleFilter:a,columns:o,defaultColumnsIds:l,requiredColumnsIds:n,selectedColumnsKey:u,groupByParams:d}){const{searchValue:p,uptimeFilter:h,peerRoleFilter:g}=D(d),{problemFilter:y}=c(),b=(0,i.Ye)(),{columnsToShow:f,columnsToSelect:C,setColumns:v}=(0,m.K)(o,u,s.uG,l,n);return(0,G.jsx)(X,{path:e,database:t,searchValue:p,problemFilter:y,uptimeFilter:h,peerRoleFilter:g,columns:f,parentRef:r,renderControls:({totalEntities:e,foundEntities:t,inited:r})=>(0,G.jsx)(K,{withGroupBySelect:b,groupByParams:d,withPeerRoleFilter:a,columnsToSelect:C,handleSelectedColumnsUpdate:v,entitiesCountCurrent:t,entitiesCountTotal:e,entitiesLoading:!r})})}function te({path:e,database:t,parentRef:r,withPeerRoleFilter:a,columns:l,defaultColumnsIds:i,requiredColumnsIds:p,selectedColumnsKey:c,groupByParams:b}){const{searchValue:f,peerRoleFilter:C,groupByParam:v}=D(b),[F]=(0,d.Nt)(),{columnsToShow:N,columnsToSelect:R,setColumns:x}=(0,m.K)(l,c,s.uG,i,p),{currentData:P,isFetching:j,error:w}=u.s.useGetNodesQuery({path:e,database:t,filter:f,filter_peer_role:C,group:v,limit:0},{pollingInterval:F}),B=void 0===P&&j,{NodeGroups:T,FoundNodes:I=0,TotalNodes:_=0}=P||{},{expandedGroups:E,setIsGroupExpanded:U}=(0,y.$)(T);return(0,G.jsxs)(n.L,{children:[(0,G.jsx)(n.L.Controls,{children:(0,G.jsx)(K,{withGroupBySelect:!0,groupByParams:b,withPeerRoleFilter:a,columnsToSelect:R,handleSelectedColumnsUpdate:x,entitiesCountCurrent:I,entitiesCountTotal:_,entitiesLoading:B})}),w?(0,G.jsx)(o.o,{error:w}):null,(0,G.jsx)(n.L.Table,{loading:B,className:V("groups-wrapper"),children:null!==T&&void 0!==T&&T.length?T.map((({name:a,count:o})=>{const l=E[a];return(0,G.jsx)(g.Q,{title:a,count:o,entityName:S("nodes"),expanded:l,onIsExpandedChange:U,children:(0,G.jsx)(X,{path:e,database:t,searchValue:f,problemFilter:"All",uptimeFilter:h.cW.All,peerRoleFilter:C,filterGroup:a,filterGroupBy:v,initialEntitiesCount:o,columns:N,parentRef:r})},a)})):S("no-nodes-groups")})]})}},15298:(e,t,r)=>{r.d(t,{s:()=>l});var a=r(21334),o=r(11906);const l=a.F.injectEndpoints({endpoints:e=>({getNodes:e.query({queryFn:async(e,{signal:t})=>{try{const r=await window.api.viewer.getNodes({type:"any",storage:!1,tablets:!0,...e},{signal:t});return{data:(0,o.N)(r)}}catch(r){return{error:r}}},providesTags:["All"]})}),overrideExisting:"throw"})},11906:(e,t,r)=>{r.d(t,{N:()=>o});var a=r(78034);const o=e=>{var t;const r=(e.Nodes||[]).map((e=>{const{SystemState:t,...r}=e;return{...r,...(0,a.q1)(t)}}));return{Nodes:r,NodeGroups:null===(t=e.NodeGroups)||void 0===t?void 0:t.map((({GroupName:e,NodeCount:t})=>{if(e&&t)return{name:e,count:Number(t)}})).filter((e=>Boolean(e))),TotalNodes:Number(e.TotalNodes)||r.length,FoundNodes:Number(e.FoundNodes)}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93033.55bd21d1.chunk.js b/ydb/core/viewer/monitoring/static/js/93033.55bd21d1.chunk.js new file mode 100644 index 000000000000..1ddc9cbf7954 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93033.55bd21d1.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93033],{93033:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"gu",weekdays:"\u0ab0\u0ab5\u0abf\u0ab5\u0abe\u0ab0_\u0ab8\u0acb\u0aae\u0ab5\u0abe\u0ab0_\u0aae\u0a82\u0a97\u0ab3\u0ab5\u0abe\u0ab0_\u0aac\u0ac1\u0aa7\u0acd\u0ab5\u0abe\u0ab0_\u0a97\u0ac1\u0ab0\u0ac1\u0ab5\u0abe\u0ab0_\u0ab6\u0ac1\u0a95\u0acd\u0ab0\u0ab5\u0abe\u0ab0_\u0ab6\u0aa8\u0abf\u0ab5\u0abe\u0ab0".split("_"),months:"\u0a9c\u0abe\u0aa8\u0acd\u0aaf\u0ac1\u0a86\u0ab0\u0ac0_\u0aab\u0ac7\u0aac\u0acd\u0ab0\u0ac1\u0a86\u0ab0\u0ac0_\u0aae\u0abe\u0ab0\u0acd\u0a9a_\u0a8f\u0aaa\u0acd\u0ab0\u0abf\u0ab2_\u0aae\u0ac7_\u0a9c\u0ac2\u0aa8_\u0a9c\u0ac1\u0ab2\u0abe\u0a88_\u0a91\u0a97\u0ab8\u0acd\u0a9f_\u0ab8\u0aaa\u0acd\u0a9f\u0ac7\u0aae\u0acd\u0aac\u0ab0_\u0a91\u0a95\u0acd\u0a9f\u0acd\u0aac\u0ab0_\u0aa8\u0ab5\u0ac7\u0aae\u0acd\u0aac\u0ab0_\u0aa1\u0abf\u0ab8\u0ac7\u0aae\u0acd\u0aac\u0ab0".split("_"),weekdaysShort:"\u0ab0\u0ab5\u0abf_\u0ab8\u0acb\u0aae_\u0aae\u0a82\u0a97\u0ab3_\u0aac\u0ac1\u0aa7\u0acd_\u0a97\u0ac1\u0ab0\u0ac1_\u0ab6\u0ac1\u0a95\u0acd\u0ab0_\u0ab6\u0aa8\u0abf".split("_"),monthsShort:"\u0a9c\u0abe\u0aa8\u0acd\u0aaf\u0ac1._\u0aab\u0ac7\u0aac\u0acd\u0ab0\u0ac1._\u0aae\u0abe\u0ab0\u0acd\u0a9a_\u0a8f\u0aaa\u0acd\u0ab0\u0abf._\u0aae\u0ac7_\u0a9c\u0ac2\u0aa8_\u0a9c\u0ac1\u0ab2\u0abe._\u0a91\u0a97._\u0ab8\u0aaa\u0acd\u0a9f\u0ac7._\u0a91\u0a95\u0acd\u0a9f\u0acd._\u0aa8\u0ab5\u0ac7._\u0aa1\u0abf\u0ab8\u0ac7.".split("_"),weekdaysMin:"\u0ab0_\u0ab8\u0acb_\u0aae\u0a82_\u0aac\u0ac1_\u0a97\u0ac1_\u0ab6\u0ac1_\u0ab6".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm \u0ab5\u0abe\u0a97\u0acd\u0aaf\u0ac7",LTS:"A h:mm:ss \u0ab5\u0abe\u0a97\u0acd\u0aaf\u0ac7",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm \u0ab5\u0abe\u0a97\u0acd\u0aaf\u0ac7",LLLL:"dddd, D MMMM YYYY, A h:mm \u0ab5\u0abe\u0a97\u0acd\u0aaf\u0ac7"},relativeTime:{future:"%s \u0aae\u0abe",past:"%s \u0aaa\u0ac7\u0ab9\u0ab2\u0abe",s:"\u0a85\u0aae\u0ac1\u0a95 \u0aaa\u0ab3\u0acb",m:"\u0a8f\u0a95 \u0aae\u0abf\u0aa8\u0abf\u0a9f",mm:"%d \u0aae\u0abf\u0aa8\u0abf\u0a9f",h:"\u0a8f\u0a95 \u0a95\u0ab2\u0abe\u0a95",hh:"%d \u0a95\u0ab2\u0abe\u0a95",d:"\u0a8f\u0a95 \u0aa6\u0abf\u0ab5\u0ab8",dd:"%d \u0aa6\u0abf\u0ab5\u0ab8",M:"\u0a8f\u0a95 \u0aae\u0ab9\u0abf\u0aa8\u0acb",MM:"%d \u0aae\u0ab9\u0abf\u0aa8\u0acb",y:"\u0a8f\u0a95 \u0ab5\u0ab0\u0acd\u0ab7",yy:"%d \u0ab5\u0ab0\u0acd\u0ab7"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9312.5eb8d4b1.chunk.js b/ydb/core/viewer/monitoring/static/js/9312.5eb8d4b1.chunk.js deleted file mode 100644 index 008c2bc13266..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9312.5eb8d4b1.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9312.5eb8d4b1.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9312],{79312:(e,s,o)=>{o.r(s),o.d(s,{conf:()=>t,language:()=>E});var t={comments:{blockComment:["(*","*)"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"[",close:"]"},{open:"{",close:"}"},{open:"(",close:")"},{open:"(*",close:"*)"},{open:"<*",close:"*>"},{open:"'",close:"'",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]}]},E={defaultToken:"",tokenPostfix:".m3",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:["AND","ANY","ARRAY","AS","BEGIN","BITS","BRANDED","BY","CASE","CONST","DIV","DO","ELSE","ELSIF","END","EVAL","EXCEPT","EXCEPTION","EXIT","EXPORTS","FINALLY","FOR","FROM","GENERIC","IF","IMPORT","IN","INTERFACE","LOCK","LOOP","METHODS","MOD","MODULE","NOT","OBJECT","OF","OR","OVERRIDES","PROCEDURE","RAISE","RAISES","READONLY","RECORD","REF","REPEAT","RETURN","REVEAL","SET","THEN","TO","TRY","TYPE","TYPECASE","UNSAFE","UNTIL","UNTRACED","VALUE","VAR","WHILE","WITH"],reservedConstNames:["ABS","ADR","ADRSIZE","BITSIZE","BYTESIZE","CEILING","DEC","DISPOSE","FALSE","FIRST","FLOAT","FLOOR","INC","ISTYPE","LAST","LOOPHOLE","MAX","MIN","NARROW","NEW","NIL","NUMBER","ORD","ROUND","SUBARRAY","TRUE","TRUNC","TYPECODE","VAL"],reservedTypeNames:["ADDRESS","ANY","BOOLEAN","CARDINAL","CHAR","EXTENDED","INTEGER","LONGCARD","LONGINT","LONGREAL","MUTEX","NULL","REAL","REFANY","ROOT","TEXT"],operators:["+","-","*","/","&","^","."],relations:["=","#","<","<=",">",">=","<:",":"],delimiters:["|","..","=>",",",";",":="],symbols:/[>=<#.,:;+\-*/&^]+/,escapes:/\\(?:[\\fnrt"']|[0-7]{3})/,tokenizer:{root:[[/_\w*/,"invalid"],[/[a-zA-Z][a-zA-Z0-9_]*/,{cases:{"@keywords":{token:"keyword.$0"},"@reservedConstNames":{token:"constant.reserved.$0"},"@reservedTypeNames":{token:"type.reserved.$0"},"@default":"identifier"}}],{include:"@whitespace"},[/[{}()\[\]]/,"@brackets"],[/[0-9]+\.[0-9]+(?:[DdEeXx][\+\-]?[0-9]+)?/,"number.float"],[/[0-9]+(?:\_[0-9a-fA-F]+)?L?/,"number"],[/@symbols/,{cases:{"@operators":"operators","@relations":"operators","@delimiters":"delimiter","@default":"invalid"}}],[/'[^\\']'/,"string.char"],[/(')(@escapes)(')/,["string.char","string.escape","string.char"]],[/'/,"invalid"],[/"([^"\\]|\\.)*$/,"invalid"],[/"/,"string.text","@text"]],text:[[/[^\\"]+/,"string.text"],[/@escapes/,"string.escape"],[/\\./,"invalid"],[/"/,"string.text","@pop"]],comment:[[/\(\*/,"comment","@push"],[/\*\)/,"comment","@pop"],[/./,"comment"]],pragma:[[/<\*/,"keyword.pragma","@push"],[/\*>/,"keyword.pragma","@pop"],[/./,"keyword.pragma"]],whitespace:[[/[ \t\r\n]+/,"white"],[/\(\*/,"comment","@comment"],[/<\*/,"keyword.pragma","@pragma"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93672.030a2ec6.chunk.js b/ydb/core/viewer/monitoring/static/js/93672.030a2ec6.chunk.js new file mode 100644 index 000000000000..e7d81378849a --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93672.030a2ec6.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93672],{68266:e=>{function i(e){e.languages.haskell={comment:{pattern:/(^|[^-!#$%*+=?&@|~.:<>^\\\/])(?:--(?:(?=.)[^-!#$%*+=?&@|~.:<>^\\\/].*|$)|\{-[\s\S]*?-\})/m,lookbehind:!0},char:{pattern:/'(?:[^\\']|\\(?:[abfnrtv\\"'&]|\^[A-Z@[\]^_]|ACK|BEL|BS|CAN|CR|DC1|DC2|DC3|DC4|DEL|DLE|EM|ENQ|EOT|ESC|ETB|ETX|FF|FS|GS|HT|LF|NAK|NUL|RS|SI|SO|SOH|SP|STX|SUB|SYN|US|VT|\d+|o[0-7]+|x[0-9a-fA-F]+))'/,alias:"string"},string:{pattern:/"(?:[^\\"]|\\(?:\S|\s+\\))*"/,greedy:!0},keyword:/\b(?:case|class|data|deriving|do|else|if|in|infixl|infixr|instance|let|module|newtype|of|primitive|then|type|where)\b/,"import-statement":{pattern:/(^[\t ]*)import\s+(?:qualified\s+)?(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*(?:\s+as\s+(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*)?(?:\s+hiding\b)?/m,lookbehind:!0,inside:{keyword:/\b(?:as|hiding|import|qualified)\b/,punctuation:/\./}},builtin:/\b(?:abs|acos|acosh|all|and|any|appendFile|approxRational|asTypeOf|asin|asinh|atan|atan2|atanh|basicIORun|break|catch|ceiling|chr|compare|concat|concatMap|const|cos|cosh|curry|cycle|decodeFloat|denominator|digitToInt|div|divMod|drop|dropWhile|either|elem|encodeFloat|enumFrom|enumFromThen|enumFromThenTo|enumFromTo|error|even|exp|exponent|fail|filter|flip|floatDigits|floatRadix|floatRange|floor|fmap|foldl|foldl1|foldr|foldr1|fromDouble|fromEnum|fromInt|fromInteger|fromIntegral|fromRational|fst|gcd|getChar|getContents|getLine|group|head|id|inRange|index|init|intToDigit|interact|ioError|isAlpha|isAlphaNum|isAscii|isControl|isDenormalized|isDigit|isHexDigit|isIEEE|isInfinite|isLower|isNaN|isNegativeZero|isOctDigit|isPrint|isSpace|isUpper|iterate|last|lcm|length|lex|lexDigits|lexLitChar|lines|log|logBase|lookup|map|mapM|mapM_|max|maxBound|maximum|maybe|min|minBound|minimum|mod|negate|not|notElem|null|numerator|odd|or|ord|otherwise|pack|pi|pred|primExitWith|print|product|properFraction|putChar|putStr|putStrLn|quot|quotRem|range|rangeSize|read|readDec|readFile|readFloat|readHex|readIO|readInt|readList|readLitChar|readLn|readOct|readParen|readSigned|reads|readsPrec|realToFrac|recip|rem|repeat|replicate|return|reverse|round|scaleFloat|scanl|scanl1|scanr|scanr1|seq|sequence|sequence_|show|showChar|showInt|showList|showLitChar|showParen|showSigned|showString|shows|showsPrec|significand|signum|sin|sinh|snd|sort|span|splitAt|sqrt|subtract|succ|sum|tail|take|takeWhile|tan|tanh|threadToIOResult|toEnum|toInt|toInteger|toLower|toRational|toUpper|truncate|uncurry|undefined|unlines|until|unwords|unzip|unzip3|userError|words|writeFile|zip|zip3|zipWith|zipWith3)\b/,number:/\b(?:\d+(?:\.\d+)?(?:e[+-]?\d+)?|0o[0-7]+|0x[0-9a-f]+)\b/i,operator:[{pattern:/`(?:[A-Z][\w']*\.)*[_a-z][\w']*`/,greedy:!0},{pattern:/(\s)\.(?=\s)/,lookbehind:!0},/[-!#$%*+=?&@|~:<>^\\\/][-!#$%*+=?&@|~.:<>^\\\/]*|\.[-!#$%*+=?&@|~.:<>^\\\/]+/],hvariable:{pattern:/\b(?:[A-Z][\w']*\.)*[_a-z][\w']*/,inside:{punctuation:/\./}},constant:{pattern:/\b(?:[A-Z][\w']*\.)*[A-Z][\w']*/,inside:{punctuation:/\./}},punctuation:/[{}[\];(),.:]/},e.languages.hs=e.languages.haskell}e.exports=i,i.displayName="haskell",i.aliases=["hs"]},90843:(e,i,a)=>{var t=a(68266);function n(e){e.register(t),e.languages.idris=e.languages.extend("haskell",{comment:{pattern:/(?:(?:--|\|\|\|).*$|\{-[\s\S]*?-\})/m},keyword:/\b(?:Type|case|class|codata|constructor|corecord|data|do|dsl|else|export|if|implementation|implicit|import|impossible|in|infix|infixl|infixr|instance|interface|let|module|mutual|namespace|of|parameters|partial|postulate|private|proof|public|quoteGoal|record|rewrite|syntax|then|total|using|where|with)\b/,builtin:void 0}),e.languages.insertBefore("idris","keyword",{"import-statement":{pattern:/(^\s*import\s+)(?:[A-Z][\w']*)(?:\.[A-Z][\w']*)*/m,lookbehind:!0,inside:{punctuation:/\./}}}),e.languages.idr=e.languages.idris}e.exports=n,n.displayName="idris",n.aliases=["idr"]},93672:(e,i,a)=>{a.d(i,{default:()=>n});var t=a(90843);const n=a.n(t)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93691.0298f4d1.chunk.js b/ydb/core/viewer/monitoring/static/js/93691.0298f4d1.chunk.js new file mode 100644 index 000000000000..882c5fbefaf8 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93691.0298f4d1.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93691],{51572:e=>{function t(e){!function(e){function t(e,t){return"___"+e.toUpperCase()+t+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(n,a,r,i){if(n.language===a){var o=n.tokenStack=[];n.code=n.code.replace(r,(function(e){if("function"===typeof i&&!i(e))return e;for(var r,s=o.length;-1!==n.code.indexOf(r=t(a,s));)++s;return o[s]=e,r})),n.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(n,a){if(n.language===a&&n.tokenStack){n.grammar=e.languages[a];var r=0,i=Object.keys(n.tokenStack);!function o(s){for(var l=0;l=i.length);l++){var u=s[l];if("string"===typeof u||u.content&&"string"===typeof u.content){var p=i[r],c=n.tokenStack[p],g="string"===typeof u?u:u.content,f=t(a,p),d=g.indexOf(f);if(d>-1){++r;var k=g.substring(0,d),b=new e.Token(a,e.tokenize(c,n.grammar),"language-"+a,c),m=g.substring(d+f.length),h=[];k&&h.push.apply(h,o([k])),h.push(b),m&&h.push.apply(h,o([m])),"string"===typeof u?s.splice.apply(s,[l,1].concat(h)):u.content=h}}else u.content&&o(u.content)}return s}(n.tokens)}}}})}(e)}e.exports=t,t.displayName="markupTemplating",t.aliases=[]},74892:(e,t,n)=>{var a=n(51572);function r(e){e.register(a),function(e){for(var t=/[^<()"']|\((?:)*\)|<(?!#--)|<#--(?:[^-]|-(?!->))*-->|"(?:[^\\"]|\\.)*"|'(?:[^\\']|\\.)*'/.source,n=0;n<2;n++)t=t.replace(//g,(function(){return t}));t=t.replace(//g,/[^\s\S]/.source);var a={comment:/<#--[\s\S]*?-->/,string:[{pattern:/\br("|')(?:(?!\1)[^\\]|\\.)*\1/,greedy:!0},{pattern:RegExp(/("|')(?:(?!\1|\$\{)[^\\]|\\.|\$\{(?:(?!\})(?:))*\})*\1/.source.replace(//g,(function(){return t}))),greedy:!0,inside:{interpolation:{pattern:RegExp(/((?:^|[^\\])(?:\\\\)*)\$\{(?:(?!\})(?:))*\}/.source.replace(//g,(function(){return t}))),lookbehind:!0,inside:{"interpolation-punctuation":{pattern:/^\$\{|\}$/,alias:"punctuation"},rest:null}}}}],keyword:/\b(?:as)\b/,boolean:/\b(?:false|true)\b/,"builtin-function":{pattern:/((?:^|[^?])\?\s*)\w+/,lookbehind:!0,alias:"function"},function:/\b\w+(?=\s*\()/,number:/\b\d+(?:\.\d+)?\b/,operator:/\.\.[<*!]?|->|--|\+\+|&&|\|\||\?{1,2}|[-+*/%!=<>]=?|\b(?:gt|gte|lt|lte)\b/,punctuation:/[,;.:()[\]{}]/};a.string[1].inside.interpolation.inside.rest=a,e.languages.ftl={"ftl-comment":{pattern:/^<#--[\s\S]*/,alias:"comment"},"ftl-directive":{pattern:/^<[\s\S]+>$/,inside:{directive:{pattern:/(^<\/?)[#@][a-z]\w*/i,lookbehind:!0,alias:"keyword"},punctuation:/^<\/?|\/?>$/,content:{pattern:/\s*\S[\s\S]*/,alias:"ftl",inside:a}}},"ftl-interpolation":{pattern:/^\$\{[\s\S]*\}$/,inside:{punctuation:/^\$\{|\}$/,content:{pattern:/\s*\S[\s\S]*/,alias:"ftl",inside:a}}}},e.hooks.add("before-tokenize",(function(n){var a=RegExp(/<#--[\s\S]*?-->|<\/?[#@][a-zA-Z](?:)*?>|\$\{(?:)*?\}/.source.replace(//g,(function(){return t})),"gi");e.languages["markup-templating"].buildPlaceholders(n,"ftl",a)})),e.hooks.add("after-tokenize",(function(t){e.languages["markup-templating"].tokenizePlaceholders(t,"ftl")}))}(e)}e.exports=r,r.displayName="ftl",r.aliases=[]},93691:(e,t,n)=>{n.d(t,{default:()=>r});var a=n(74892);const r=n.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93696.ebf5e5d2.chunk.js b/ydb/core/viewer/monitoring/static/js/93696.ebf5e5d2.chunk.js new file mode 100644 index 000000000000..1cb8695a8c45 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93696.ebf5e5d2.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93696],{83445:e=>{function a(e){!function(e){var a,n=/("|')(?:\\(?:\r\n|[\s\S])|(?!\1)[^\\\r\n])*\1/;e.languages.css.selector={pattern:e.languages.css.selector.pattern,lookbehind:!0,inside:a={"pseudo-element":/:(?:after|before|first-letter|first-line|selection)|::[-\w]+/,"pseudo-class":/:[-\w]+/,class:/\.[-\w]+/,id:/#[-\w]+/,attribute:{pattern:RegExp("\\[(?:[^[\\]\"']|"+n.source+")*\\]"),greedy:!0,inside:{punctuation:/^\[|\]$/,"case-sensitivity":{pattern:/(\s)[si]$/i,lookbehind:!0,alias:"keyword"},namespace:{pattern:/^(\s*)(?:(?!\s)[-*\w\xA0-\uFFFF])*\|(?!=)/,lookbehind:!0,inside:{punctuation:/\|$/}},"attr-name":{pattern:/^(\s*)(?:(?!\s)[-\w\xA0-\uFFFF])+/,lookbehind:!0},"attr-value":[n,{pattern:/(=\s*)(?:(?!\s)[-\w\xA0-\uFFFF])+(?=\s*$)/,lookbehind:!0}],operator:/[|~*^$]?=/}},"n-th":[{pattern:/(\(\s*)[+-]?\d*[\dn](?:\s*[+-]\s*\d+)?(?=\s*\))/,lookbehind:!0,inside:{number:/[\dn]+/,operator:/[+-]/}},{pattern:/(\(\s*)(?:even|odd)(?=\s*\))/i,lookbehind:!0}],combinator:/>|\+|~|\|\|/,punctuation:/[(),]/}},e.languages.css.atrule.inside["selector-function-argument"].inside=a,e.languages.insertBefore("css","property",{variable:{pattern:/(^|[^-\w\xA0-\uFFFF])--(?!\s)[-_a-z\xA0-\uFFFF](?:(?!\s)[-\w\xA0-\uFFFF])*/i,lookbehind:!0}});var r={pattern:/(\b\d+)(?:%|[a-z]+(?![\w-]))/,lookbehind:!0},i={pattern:/(^|[^\w.-])-?(?:\d+(?:\.\d+)?|\.\d+)/,lookbehind:!0};e.languages.insertBefore("css","function",{operator:{pattern:/(\s)[+\-*\/](?=\s)/,lookbehind:!0},hexcode:{pattern:/\B#[\da-f]{3,8}\b/i,alias:"color"},color:[{pattern:/(^|[^\w-])(?:AliceBlue|AntiqueWhite|Aqua|Aquamarine|Azure|Beige|Bisque|Black|BlanchedAlmond|Blue|BlueViolet|Brown|BurlyWood|CadetBlue|Chartreuse|Chocolate|Coral|CornflowerBlue|Cornsilk|Crimson|Cyan|DarkBlue|DarkCyan|DarkGoldenRod|DarkGr[ae]y|DarkGreen|DarkKhaki|DarkMagenta|DarkOliveGreen|DarkOrange|DarkOrchid|DarkRed|DarkSalmon|DarkSeaGreen|DarkSlateBlue|DarkSlateGr[ae]y|DarkTurquoise|DarkViolet|DeepPink|DeepSkyBlue|DimGr[ae]y|DodgerBlue|FireBrick|FloralWhite|ForestGreen|Fuchsia|Gainsboro|GhostWhite|Gold|GoldenRod|Gr[ae]y|Green|GreenYellow|HoneyDew|HotPink|IndianRed|Indigo|Ivory|Khaki|Lavender|LavenderBlush|LawnGreen|LemonChiffon|LightBlue|LightCoral|LightCyan|LightGoldenRodYellow|LightGr[ae]y|LightGreen|LightPink|LightSalmon|LightSeaGreen|LightSkyBlue|LightSlateGr[ae]y|LightSteelBlue|LightYellow|Lime|LimeGreen|Linen|Magenta|Maroon|MediumAquaMarine|MediumBlue|MediumOrchid|MediumPurple|MediumSeaGreen|MediumSlateBlue|MediumSpringGreen|MediumTurquoise|MediumVioletRed|MidnightBlue|MintCream|MistyRose|Moccasin|NavajoWhite|Navy|OldLace|Olive|OliveDrab|Orange|OrangeRed|Orchid|PaleGoldenRod|PaleGreen|PaleTurquoise|PaleVioletRed|PapayaWhip|PeachPuff|Peru|Pink|Plum|PowderBlue|Purple|Red|RosyBrown|RoyalBlue|SaddleBrown|Salmon|SandyBrown|SeaGreen|SeaShell|Sienna|Silver|SkyBlue|SlateBlue|SlateGr[ae]y|Snow|SpringGreen|SteelBlue|Tan|Teal|Thistle|Tomato|Transparent|Turquoise|Violet|Wheat|White|WhiteSmoke|Yellow|YellowGreen)(?![\w-])/i,lookbehind:!0},{pattern:/\b(?:hsl|rgb)\(\s*\d{1,3}\s*,\s*\d{1,3}%?\s*,\s*\d{1,3}%?\s*\)\B|\b(?:hsl|rgb)a\(\s*\d{1,3}\s*,\s*\d{1,3}%?\s*,\s*\d{1,3}%?\s*,\s*(?:0|0?\.\d+|1)\s*\)\B/i,inside:{unit:r,number:i,function:/[\w-]+(?=\()/,punctuation:/[(),]/}}],entity:/\\[\da-f]{1,8}/i,unit:r,number:i})}(e)}e.exports=a,a.displayName="cssExtras",a.aliases=[]},93696:(e,a,n)=>{n.d(a,{default:()=>i});var r=n(83445);const i=n.n(r)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93756.c3c309ab.chunk.js b/ydb/core/viewer/monitoring/static/js/93756.c3c309ab.chunk.js new file mode 100644 index 000000000000..7e9813178899 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93756.c3c309ab.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93756],{93756:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"pa-in",weekdays:"\u0a10\u0a24\u0a35\u0a3e\u0a30_\u0a38\u0a4b\u0a2e\u0a35\u0a3e\u0a30_\u0a2e\u0a70\u0a17\u0a32\u0a35\u0a3e\u0a30_\u0a2c\u0a41\u0a27\u0a35\u0a3e\u0a30_\u0a35\u0a40\u0a30\u0a35\u0a3e\u0a30_\u0a38\u0a3c\u0a41\u0a71\u0a15\u0a30\u0a35\u0a3e\u0a30_\u0a38\u0a3c\u0a28\u0a40\u0a1a\u0a30\u0a35\u0a3e\u0a30".split("_"),months:"\u0a1c\u0a28\u0a35\u0a30\u0a40_\u0a2b\u0a3c\u0a30\u0a35\u0a30\u0a40_\u0a2e\u0a3e\u0a30\u0a1a_\u0a05\u0a2a\u0a4d\u0a30\u0a48\u0a32_\u0a2e\u0a08_\u0a1c\u0a42\u0a28_\u0a1c\u0a41\u0a32\u0a3e\u0a08_\u0a05\u0a17\u0a38\u0a24_\u0a38\u0a24\u0a70\u0a2c\u0a30_\u0a05\u0a15\u0a24\u0a42\u0a2c\u0a30_\u0a28\u0a35\u0a70\u0a2c\u0a30_\u0a26\u0a38\u0a70\u0a2c\u0a30".split("_"),weekdaysShort:"\u0a10\u0a24_\u0a38\u0a4b\u0a2e_\u0a2e\u0a70\u0a17\u0a32_\u0a2c\u0a41\u0a27_\u0a35\u0a40\u0a30_\u0a38\u0a3c\u0a41\u0a15\u0a30_\u0a38\u0a3c\u0a28\u0a40".split("_"),monthsShort:"\u0a1c\u0a28\u0a35\u0a30\u0a40_\u0a2b\u0a3c\u0a30\u0a35\u0a30\u0a40_\u0a2e\u0a3e\u0a30\u0a1a_\u0a05\u0a2a\u0a4d\u0a30\u0a48\u0a32_\u0a2e\u0a08_\u0a1c\u0a42\u0a28_\u0a1c\u0a41\u0a32\u0a3e\u0a08_\u0a05\u0a17\u0a38\u0a24_\u0a38\u0a24\u0a70\u0a2c\u0a30_\u0a05\u0a15\u0a24\u0a42\u0a2c\u0a30_\u0a28\u0a35\u0a70\u0a2c\u0a30_\u0a26\u0a38\u0a70\u0a2c\u0a30".split("_"),weekdaysMin:"\u0a10\u0a24_\u0a38\u0a4b\u0a2e_\u0a2e\u0a70\u0a17\u0a32_\u0a2c\u0a41\u0a27_\u0a35\u0a40\u0a30_\u0a38\u0a3c\u0a41\u0a15\u0a30_\u0a38\u0a3c\u0a28\u0a40".split("_"),ordinal:function(_){return _},formats:{LT:"A h:mm \u0a35\u0a1c\u0a47",LTS:"A h:mm:ss \u0a35\u0a1c\u0a47",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY, A h:mm \u0a35\u0a1c\u0a47",LLLL:"dddd, D MMMM YYYY, A h:mm \u0a35\u0a1c\u0a47"},relativeTime:{future:"%s \u0a35\u0a3f\u0a71\u0a1a",past:"%s \u0a2a\u0a3f\u0a1b\u0a32\u0a47",s:"\u0a15\u0a41\u0a1d \u0a38\u0a15\u0a3f\u0a70\u0a1f",m:"\u0a07\u0a15 \u0a2e\u0a3f\u0a70\u0a1f",mm:"%d \u0a2e\u0a3f\u0a70\u0a1f",h:"\u0a07\u0a71\u0a15 \u0a18\u0a70\u0a1f\u0a3e",hh:"%d \u0a18\u0a70\u0a1f\u0a47",d:"\u0a07\u0a71\u0a15 \u0a26\u0a3f\u0a28",dd:"%d \u0a26\u0a3f\u0a28",M:"\u0a07\u0a71\u0a15 \u0a2e\u0a39\u0a40\u0a28\u0a3e",MM:"%d \u0a2e\u0a39\u0a40\u0a28\u0a47",y:"\u0a07\u0a71\u0a15 \u0a38\u0a3e\u0a32",yy:"%d \u0a38\u0a3e\u0a32"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93771.f96f428a.chunk.js b/ydb/core/viewer/monitoring/static/js/93771.f96f428a.chunk.js new file mode 100644 index 000000000000..000e94ead286 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93771.f96f428a.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93771],{34280:a=>{function e(a){a.languages.nevod={comment:/\/\/.*|(?:\/\*[\s\S]*?(?:\*\/|$))/,string:{pattern:/(?:"(?:""|[^"])*"(?!")|'(?:''|[^'])*'(?!'))!?\*?/,greedy:!0,inside:{"string-attrs":/!$|!\*$|\*$/}},namespace:{pattern:/(@namespace\s+)[a-zA-Z0-9\-.]+(?=\s*\{)/,lookbehind:!0},pattern:{pattern:/(@pattern\s+)?#?[a-zA-Z0-9\-.]+(?:\s*\(\s*(?:~\s*)?[a-zA-Z0-9\-.]+\s*(?:,\s*(?:~\s*)?[a-zA-Z0-9\-.]*)*\))?(?=\s*=)/,lookbehind:!0,inside:{"pattern-name":{pattern:/^#?[a-zA-Z0-9\-.]+/,alias:"class-name"},fields:{pattern:/\(.*\)/,inside:{"field-name":{pattern:/[a-zA-Z0-9\-.]+/,alias:"variable"},punctuation:/[,()]/,operator:{pattern:/~/,alias:"field-hidden-mark"}}}}},search:{pattern:/(@search\s+|#)[a-zA-Z0-9\-.]+(?:\.\*)?(?=\s*;)/,alias:"function",lookbehind:!0},keyword:/@(?:having|inside|namespace|outside|pattern|require|search|where)\b/,"standard-pattern":{pattern:/\b(?:Alpha|AlphaNum|Any|Blank|End|LineBreak|Num|NumAlpha|Punct|Space|Start|Symbol|Word|WordBreak)\b(?:\([a-zA-Z0-9\-.,\s+]*\))?/,inside:{"standard-pattern-name":{pattern:/^[a-zA-Z0-9\-.]+/,alias:"builtin"},quantifier:{pattern:/\b\d+(?:\s*\+|\s*-\s*\d+)?(?!\w)/,alias:"number"},"standard-pattern-attr":{pattern:/[a-zA-Z0-9\-.]+/,alias:"builtin"},punctuation:/[,()]/}},quantifier:{pattern:/\b\d+(?:\s*\+|\s*-\s*\d+)?(?!\w)/,alias:"number"},operator:[{pattern:/=/,alias:"pattern-def"},{pattern:/&/,alias:"conjunction"},{pattern:/~/,alias:"exception"},{pattern:/\?/,alias:"optionality"},{pattern:/[[\]]/,alias:"repetition"},{pattern:/[{}]/,alias:"variation"},{pattern:/[+_]/,alias:"sequence"},{pattern:/\.{2,3}/,alias:"span"}],"field-capture":[{pattern:/([a-zA-Z0-9\-.]+\s*\()\s*[a-zA-Z0-9\-.]+\s*:\s*[a-zA-Z0-9\-.]+(?:\s*,\s*[a-zA-Z0-9\-.]+\s*:\s*[a-zA-Z0-9\-.]+)*(?=\s*\))/,lookbehind:!0,inside:{"field-name":{pattern:/[a-zA-Z0-9\-.]+/,alias:"variable"},colon:/:/}},{pattern:/[a-zA-Z0-9\-.]+\s*:/,inside:{"field-name":{pattern:/[a-zA-Z0-9\-.]+/,alias:"variable"},colon:/:/}}],punctuation:/[:;,()]/,name:/[a-zA-Z0-9\-.]+/}}a.exports=e,e.displayName="nevod",e.aliases=[]},93771:(a,e,t)=>{t.d(e,{default:()=>s});var n=t(34280);const s=t.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/93890.f4cf2ce4.chunk.js b/ydb/core/viewer/monitoring/static/js/93890.f4cf2ce4.chunk.js new file mode 100644 index 000000000000..afa25f8681cc --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/93890.f4cf2ce4.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[93890],{16151:e=>{function a(e){e.languages.eiffel={comment:/--.*/,string:[{pattern:/"([^[]*)\[[\s\S]*?\]\1"/,greedy:!0},{pattern:/"([^{]*)\{[\s\S]*?\}\1"/,greedy:!0},{pattern:/"(?:%(?:(?!\n)\s)*\n\s*%|%\S|[^%"\r\n])*"/,greedy:!0}],char:/'(?:%.|[^%'\r\n])+'/,keyword:/\b(?:across|agent|alias|all|and|as|assign|attached|attribute|check|class|convert|create|Current|debug|deferred|detachable|do|else|elseif|end|ensure|expanded|export|external|feature|from|frozen|if|implies|inherit|inspect|invariant|like|local|loop|not|note|obsolete|old|once|or|Precursor|redefine|rename|require|rescue|Result|retry|select|separate|some|then|undefine|until|variant|Void|when|xor)\b/i,boolean:/\b(?:False|True)\b/i,"class-name":/\b[A-Z][\dA-Z_]*\b/,number:[/\b0[xcb][\da-f](?:_*[\da-f])*\b/i,/(?:\b\d(?:_*\d)*)?\.(?:(?:\d(?:_*\d)*)?e[+-]?)?\d(?:_*\d)*\b|\b\d(?:_*\d)*\b\.?/i],punctuation:/:=|<<|>>|\(\||\|\)|->|\.(?=\w)|[{}[\];(),:?]/,operator:/\\\\|\|\.\.\||\.\.|\/[~\/=]?|[><]=?|[-+*^=~]/}}e.exports=a,a.displayName="eiffel",a.aliases=[]},93890:(e,a,r)=>{r.d(a,{default:()=>t});var n=r(16151);const t=r.n(n)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9394.ca56f408.chunk.js b/ydb/core/viewer/monitoring/static/js/9394.ca56f408.chunk.js deleted file mode 100644 index c0cb046fa493..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9394.ca56f408.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9394.ca56f408.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9394],{29394:(e,t,n)=>{n.r(t),n.d(t,{conf:()=>o,language:()=>a});var o={comments:{lineComment:"//"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"'",close:"'",notIn:["string","comment"]},{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]}],folding:{offSide:!0}},a={defaultToken:"",tokenPostfix:".pug",ignoreCase:!0,brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.array",open:"[",close:"]"},{token:"delimiter.parenthesis",open:"(",close:")"}],keywords:["append","block","case","default","doctype","each","else","extends","for","if","in","include","mixin","typeof","unless","var","when"],tags:["a","abbr","acronym","address","area","article","aside","audio","b","base","basefont","bdi","bdo","blockquote","body","br","button","canvas","caption","center","cite","code","col","colgroup","command","datalist","dd","del","details","dfn","div","dl","dt","em","embed","fieldset","figcaption","figure","font","footer","form","frame","frameset","h1","h2","h3","h4","h5","h6","head","header","hgroup","hr","html","i","iframe","img","input","ins","keygen","kbd","label","li","link","map","mark","menu","meta","meter","nav","noframes","noscript","object","ol","optgroup","option","output","p","param","pre","progress","q","rp","rt","ruby","s","samp","script","section","select","small","source","span","strike","strong","style","sub","summary","sup","table","tbody","td","textarea","tfoot","th","thead","time","title","tr","tracks","tt","u","ul","video","wbr"],symbols:/[\+\-\*\%\&\|\!\=\/\.\,\:]+/,escapes:/\\(?:[abfnrtv\\"']|x[0-9A-Fa-f]{1,4}|u[0-9A-Fa-f]{4}|U[0-9A-Fa-f]{8})/,tokenizer:{root:[[/^(\s*)([a-zA-Z_-][\w-]*)/,{cases:{"$2@tags":{cases:{"@eos":["","tag"],"@default":["",{token:"tag",next:"@tag.$1"}]}},"$2@keywords":["",{token:"keyword.$2"}],"@default":["",""]}}],[/^(\s*)(#[a-zA-Z_-][\w-]*)/,{cases:{"@eos":["","tag.id"],"@default":["",{token:"tag.id",next:"@tag.$1"}]}}],[/^(\s*)(\.[a-zA-Z_-][\w-]*)/,{cases:{"@eos":["","tag.class"],"@default":["",{token:"tag.class",next:"@tag.$1"}]}}],[/^(\s*)(\|.*)$/,""],{include:"@whitespace"},[/[a-zA-Z_$][\w$]*/,{cases:{"@keywords":{token:"keyword.$0"},"@default":""}}],[/[{}()\[\]]/,"@brackets"],[/@symbols/,"delimiter"],[/\d+\.\d+([eE][\-+]?\d+)?/,"number.float"],[/\d+/,"number"],[/"/,"string",'@string."'],[/'/,"string","@string.'"]],tag:[[/(\.)(\s*$)/,[{token:"delimiter",next:"@blockText.$S2."},""]],[/\s+/,{token:"",next:"@simpleText"}],[/#[a-zA-Z_-][\w-]*/,{cases:{"@eos":{token:"tag.id",next:"@pop"},"@default":"tag.id"}}],[/\.[a-zA-Z_-][\w-]*/,{cases:{"@eos":{token:"tag.class",next:"@pop"},"@default":"tag.class"}}],[/\(/,{token:"delimiter.parenthesis",next:"@attributeList"}]],simpleText:[[/[^#]+$/,{token:"",next:"@popall"}],[/[^#]+/,{token:""}],[/(#{)([^}]*)(})/,{cases:{"@eos":["interpolation.delimiter","interpolation",{token:"interpolation.delimiter",next:"@popall"}],"@default":["interpolation.delimiter","interpolation","interpolation.delimiter"]}}],[/#$/,{token:"",next:"@popall"}],[/#/,""]],attributeList:[[/\s+/,""],[/(\w+)(\s*=\s*)("|')/,["attribute.name","delimiter",{token:"attribute.value",next:"@value.$3"}]],[/\w+/,"attribute.name"],[/,/,{cases:{"@eos":{token:"attribute.delimiter",next:"@popall"},"@default":"attribute.delimiter"}}],[/\)$/,{token:"delimiter.parenthesis",next:"@popall"}],[/\)/,{token:"delimiter.parenthesis",next:"@pop"}]],whitespace:[[/^(\s*)(\/\/.*)$/,{token:"comment",next:"@blockText.$1.comment"}],[/[ \t\r\n]+/,""],[//,{token:"comment",next:"@pop"}],[//,"comment","@pop"],[/[^-]+/,"comment.content"],[/./,"comment.content"]],otherTag:[[/\/?>/,"delimiter","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],script:[[/type/,"attribute.name","@scriptAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter",next:"@scriptEmbedded",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/(<\/)(script\s*)(>)/,["delimiter","tag",{token:"delimiter",next:"@pop"}]]],scriptAfterType:[[/=/,"delimiter","@scriptAfterTypeEquals"],[/>/,{token:"delimiter",next:"@scriptEmbedded",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptAfterTypeEquals:[[/"module"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.text/javascript"}],[/'module'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.text/javascript"}],[/"([^"]*)"/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@scriptWithCustomType.$1"}],[/>/,{token:"delimiter",next:"@scriptEmbedded",nextEmbedded:"text/javascript"}],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptWithCustomType:[[/>/,{token:"delimiter",next:"@scriptEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/script\s*>/,{token:"@rematch",next:"@pop"}]],scriptEmbedded:[[/<\/script/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}],[/[^<]+/,""]],style:[[/type/,"attribute.name","@styleAfterType"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/>/,{token:"delimiter",next:"@styleEmbedded",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/(<\/)(style\s*)(>)/,["delimiter","tag",{token:"delimiter",next:"@pop"}]]],styleAfterType:[[/=/,"delimiter","@styleAfterTypeEquals"],[/>/,{token:"delimiter",next:"@styleEmbedded",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleAfterTypeEquals:[[/"([^"]*)"/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/'([^']*)'/,{token:"attribute.value",switchTo:"@styleWithCustomType.$1"}],[/>/,{token:"delimiter",next:"@styleEmbedded",nextEmbedded:"text/css"}],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleWithCustomType:[[/>/,{token:"delimiter",next:"@styleEmbedded.$S2",nextEmbedded:"$S2"}],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/],[/<\/style\s*>/,{token:"@rematch",next:"@pop"}]],styleEmbedded:[[/<\/style/,{token:"@rematch",next:"@pop",nextEmbedded:"@pop"}],[/[^<]+/,""]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/957.08a1c505.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/96554.bff09e47.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/957.08a1c505.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/96554.bff09e47.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/9697.bed5988b.chunk.js b/ydb/core/viewer/monitoring/static/js/9697.bed5988b.chunk.js deleted file mode 100644 index bec49fb7699a..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9697.bed5988b.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9697],{89697:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),d={name:"ar-ma",weekdays:"\u0627\u0644\u0623\u062d\u062f_\u0627\u0644\u0625\u062b\u0646\u064a\u0646_\u0627\u0644\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0644\u0623\u0631\u0628\u0639\u0627\u0621_\u0627\u0644\u062e\u0645\u064a\u0633_\u0627\u0644\u062c\u0645\u0639\u0629_\u0627\u0644\u0633\u0628\u062a".split("_"),months:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648\u0632_\u063a\u0634\u062a_\u0634\u062a\u0646\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0646\u0628\u0631_\u062f\u062c\u0646\u0628\u0631".split("_"),weekStart:6,weekdaysShort:"\u0627\u062d\u062f_\u0625\u062b\u0646\u064a\u0646_\u062b\u0644\u0627\u062b\u0627\u0621_\u0627\u0631\u0628\u0639\u0627\u0621_\u062e\u0645\u064a\u0633_\u062c\u0645\u0639\u0629_\u0633\u0628\u062a".split("_"),monthsShort:"\u064a\u0646\u0627\u064a\u0631_\u0641\u0628\u0631\u0627\u064a\u0631_\u0645\u0627\u0631\u0633_\u0623\u0628\u0631\u064a\u0644_\u0645\u0627\u064a_\u064a\u0648\u0646\u064a\u0648_\u064a\u0648\u0644\u064a\u0648\u0632_\u063a\u0634\u062a_\u0634\u062a\u0646\u0628\u0631_\u0623\u0643\u062a\u0648\u0628\u0631_\u0646\u0648\u0646\u0628\u0631_\u062f\u062c\u0646\u0628\u0631".split("_"),weekdaysMin:"\u062d_\u0646_\u062b_\u0631_\u062e_\u062c_\u0633".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"D MMMM YYYY",LLL:"D MMMM YYYY HH:mm",LLLL:"dddd D MMMM YYYY HH:mm"},meridiem:function(_){return _>12?"\u0645":"\u0635"},relativeTime:{future:"\u0641\u064a %s",past:"\u0645\u0646\u0630 %s",s:"\u062b\u0648\u0627\u0646",m:"\u062f\u0642\u064a\u0642\u0629",mm:"%d \u062f\u0642\u0627\u0626\u0642",h:"\u0633\u0627\u0639\u0629",hh:"%d \u0633\u0627\u0639\u0627\u062a",d:"\u064a\u0648\u0645",dd:"%d \u0623\u064a\u0627\u0645",M:"\u0634\u0647\u0631",MM:"%d \u0623\u0634\u0647\u0631",y:"\u0633\u0646\u0629",yy:"%d \u0633\u0646\u0648\u0627\u062a"}};return t.default.locale(d,null,!0),d}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9707.72e68790.chunk.js b/ydb/core/viewer/monitoring/static/js/9707.72e68790.chunk.js deleted file mode 100644 index 789ded2dfc5d..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9707.72e68790.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9707],{79707:function(a,e,_){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var _=e(a),t="sije\u010dnja_velja\u010de_o\u017eujka_travnja_svibnja_lipnja_srpnja_kolovoza_rujna_listopada_studenoga_prosinca".split("_"),s="sije\u010danj_velja\u010da_o\u017eujak_travanj_svibanj_lipanj_srpanj_kolovoz_rujan_listopad_studeni_prosinac".split("_"),n=/D[oD]?(\[[^[\]]*\]|\s)+MMMM?/,i=function(a,e){return n.test(e)?t[a.month()]:s[a.month()]};i.s=s,i.f=t;var o={name:"hr",weekdays:"nedjelja_ponedjeljak_utorak_srijeda_\u010detvrtak_petak_subota".split("_"),weekdaysShort:"ned._pon._uto._sri._\u010det._pet._sub.".split("_"),weekdaysMin:"ne_po_ut_sr_\u010de_pe_su".split("_"),months:i,monthsShort:"sij._velj._o\u017eu._tra._svi._lip._srp._kol._ruj._lis._stu._pro.".split("_"),weekStart:1,formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm"},relativeTime:{future:"za %s",past:"prije %s",s:"sekunda",m:"minuta",mm:"%d minuta",h:"sat",hh:"%d sati",d:"dan",dd:"%d dana",M:"mjesec",MM:"%d mjeseci",y:"godina",yy:"%d godine"},ordinal:function(a){return a+"."}};return _.default.locale(o,null,!0),o}(_(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9725.a94823a0.chunk.js b/ydb/core/viewer/monitoring/static/js/9725.a94823a0.chunk.js deleted file mode 100644 index e7753223d8d9..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9725.a94823a0.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9725],{49725:function(e,_,s){e.exports=function(e){"use strict";function _(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var s=_(e),o={name:"es",monthsShort:"ene_feb_mar_abr_may_jun_jul_ago_sep_oct_nov_dic".split("_"),weekdays:"domingo_lunes_martes_mi\xe9rcoles_jueves_viernes_s\xe1bado".split("_"),weekdaysShort:"dom._lun._mar._mi\xe9._jue._vie._s\xe1b.".split("_"),weekdaysMin:"do_lu_ma_mi_ju_vi_s\xe1".split("_"),months:"enero_febrero_marzo_abril_mayo_junio_julio_agosto_septiembre_octubre_noviembre_diciembre".split("_"),weekStart:1,formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD/MM/YYYY",LL:"D [de] MMMM [de] YYYY",LLL:"D [de] MMMM [de] YYYY H:mm",LLLL:"dddd, D [de] MMMM [de] YYYY H:mm"},relativeTime:{future:"en %s",past:"hace %s",s:"unos segundos",m:"un minuto",mm:"%d minutos",h:"una hora",hh:"%d horas",d:"un d\xeda",dd:"%d d\xedas",M:"un mes",MM:"%d meses",y:"un a\xf1o",yy:"%d a\xf1os"},ordinal:function(e){return e+"\xba"}};return s.default.locale(o,null,!0),o}(s(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9728.7cc957e4.chunk.js b/ydb/core/viewer/monitoring/static/js/9728.7cc957e4.chunk.js deleted file mode 100644 index d9ad263493d8..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9728.7cc957e4.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9728.7cc957e4.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9728],{19728:(e,t,i)=>{i.r(t),i.d(t,{conf:()=>p,language:()=>w});var n,o,r=i(80781),l=Object.defineProperty,a=Object.getOwnPropertyDescriptor,d=Object.getOwnPropertyNames,s=Object.prototype.hasOwnProperty,u=(e,t,i,n)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let o of d(t))s.call(e,o)||o===i||l(e,o,{get:()=>t[o],enumerable:!(n=a(t,o))||n.enumerable});return e},c={};u(c,n=r,"default"),o&&u(o,n,"default");var m=["area","base","br","col","embed","hr","img","input","keygen","link","menuitem","meta","param","source","track","wbr"],p={wordPattern:/(-?\d*\.\d\w*)|([^\`\~\!\@\$\^\&\*\(\)\=\+\[\{\]\}\\\|\;\:\'\"\,\.\<\>\/\s]+)/g,brackets:[["\x3c!--","--\x3e"],["<",">"],["{{","}}"],["{%","%}"],["{","}"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"%",close:"%"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"}],onEnterRules:[{beforeText:new RegExp(`<(?!(?:${m.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),afterText:/^<\/(\w[\w\d]*)\s*>$/i,action:{indentAction:c.languages.IndentAction.IndentOutdent}},{beforeText:new RegExp(`<(?!(?:${m.join("|")}))(\\w[\\w\\d]*)([^/>]*(?!/)>)[^<]*$`,"i"),action:{indentAction:c.languages.IndentAction.Indent}}]},w={defaultToken:"",tokenPostfix:"",builtinTags:["if","else","elseif","endif","render","assign","capture","endcapture","case","endcase","comment","endcomment","cycle","decrement","for","endfor","include","increment","layout","raw","endraw","render","tablerow","endtablerow","unless","endunless"],builtinFilters:["abs","append","at_least","at_most","capitalize","ceil","compact","date","default","divided_by","downcase","escape","escape_once","first","floor","join","json","last","lstrip","map","minus","modulo","newline_to_br","plus","prepend","remove","remove_first","replace","replace_first","reverse","round","rstrip","size","slice","sort","sort_natural","split","strip","strip_html","strip_newlines","times","truncate","truncatewords","uniq","upcase","url_decode","url_encode","where"],constants:["true","false"],operators:["==","!=",">","<",">=","<="],symbol:/[=>)/,["delimiter.html","tag.html","delimiter.html"]],[/(<)([:\w]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[/(<\/)([\w\-]+)/,["delimiter.html",{token:"tag.html",next:"@otherTag"}]],[//,"delimiter.html","@pop"],[/"([^"]*)"/,"attribute.value"],[/'([^']*)'/,"attribute.value"],[/[\w\-]+/,"attribute.name"],[/=/,"delimiter"],[/[ \t\r\n]+/]],liquidState:[[/\{\{/,"delimiter.output.liquid"],[/\}\}/,{token:"delimiter.output.liquid",switchTo:"@$S2.$S3"}],[/\{\%/,"delimiter.tag.liquid"],[/raw\s*\%\}/,"delimiter.tag.liquid","@liquidRaw"],[/\%\}/,{token:"delimiter.tag.liquid",switchTo:"@$S2.$S3"}],{include:"liquidRoot"}],liquidRaw:[[/^(?!\{\%\s*endraw\s*\%\}).+/],[/\{\%/,"delimiter.tag.liquid"],[/@identifier/],[/\%\}/,{token:"delimiter.tag.liquid",next:"@root"}]],liquidRoot:[[/\d+(\.\d+)?/,"number.liquid"],[/"[^"]*"/,"string.liquid"],[/'[^']*'/,"string.liquid"],[/\s+/],[/@symbol/,{cases:{"@operators":"operator.liquid","@default":""}}],[/\./],[/@identifier/,{cases:{"@constants":"keyword.liquid","@builtinFilters":"predefined.liquid","@builtinTags":"predefined.liquid","@default":"variable.liquid"}}],[/[^}|%]/,"variable.liquid"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/97420.08729928.chunk.js b/ydb/core/viewer/monitoring/static/js/97420.08729928.chunk.js new file mode 100644 index 000000000000..e4fa61379196 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/97420.08729928.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[97420],{97420:function(a,e,l){a.exports=function(a){"use strict";function e(a){return a&&"object"==typeof a&&"default"in a?a:{default:a}}var l=e(a),_={name:"bm",weekdays:"Kari_Nt\u025bn\u025bn_Tarata_Araba_Alamisa_Juma_Sibiri".split("_"),months:"Zanwuyekalo_Fewuruyekalo_Marisikalo_Awirilikalo_M\u025bkalo_Zuw\u025bnkalo_Zuluyekalo_Utikalo_S\u025btanburukalo_\u0254kut\u0254burukalo_Nowanburukalo_Desanburukalo".split("_"),weekStart:1,weekdaysShort:"Kar_Nt\u025b_Tar_Ara_Ala_Jum_Sib".split("_"),monthsShort:"Zan_Few_Mar_Awi_M\u025b_Zuw_Zul_Uti_S\u025bt_\u0254ku_Now_Des".split("_"),weekdaysMin:"Ka_Nt_Ta_Ar_Al_Ju_Si".split("_"),ordinal:function(a){return a},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD/MM/YYYY",LL:"MMMM [tile] D [san] YYYY",LLL:"MMMM [tile] D [san] YYYY [l\u025br\u025b] HH:mm",LLLL:"dddd MMMM [tile] D [san] YYYY [l\u025br\u025b] HH:mm"},relativeTime:{future:"%s k\u0254n\u0254",past:"a b\u025b %s b\u0254",s:"sanga dama dama",m:"miniti kelen",mm:"miniti %d",h:"l\u025br\u025b kelen",hh:"l\u025br\u025b %d",d:"tile kelen",dd:"tile %d",M:"kalo kelen",MM:"kalo %d",y:"san kelen",yy:"san %d"}};return l.default.locale(_,null,!0),_}(l(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/97440.3db00b72.chunk.js b/ydb/core/viewer/monitoring/static/js/97440.3db00b72.chunk.js new file mode 100644 index 000000000000..b42500477728 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/97440.3db00b72.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[97440],{97440:(n,t,a)=>{a.d(t,{default:()=>i});var e=a(99231);const i=a.n(e)()},99231:n=>{function t(n){!function(n){n.languages.xeora=n.languages.extend("markup",{constant:{pattern:/\$(?:DomainContents|PageRenderDuration)\$/,inside:{punctuation:{pattern:/\$/}}},variable:{pattern:/\$@?(?:#+|[-+*~=^])?[\w.]+\$/,inside:{punctuation:{pattern:/[$.]/},operator:{pattern:/#+|[-+*~=^@]/}}},"function-inline":{pattern:/\$F:[-\w.]+\?[-\w.]+(?:,(?:(?:@[-#]*\w+\.[\w+.]\.*)*\|)*(?:(?:[\w+]|[-#*.~^]+[\w+]|=\S)(?:[^$=]|=+[^=])*=*|(?:@[-#]*\w+\.[\w+.]\.*)+(?:(?:[\w+]|[-#*~^][-#*.~^]*[\w+]|=\S)(?:[^$=]|=+[^=])*=*)?)?)?\$/,inside:{variable:{pattern:/(?:[,|])@?(?:#+|[-+*~=^])?[\w.]+/,inside:{punctuation:{pattern:/[,.|]/},operator:{pattern:/#+|[-+*~=^@]/}}},punctuation:{pattern:/\$\w:|[$:?.,|]/}},alias:"function"},"function-block":{pattern:/\$XF:\{[-\w.]+\?[-\w.]+(?:,(?:(?:@[-#]*\w+\.[\w+.]\.*)*\|)*(?:(?:[\w+]|[-#*.~^]+[\w+]|=\S)(?:[^$=]|=+[^=])*=*|(?:@[-#]*\w+\.[\w+.]\.*)+(?:(?:[\w+]|[-#*~^][-#*.~^]*[\w+]|=\S)(?:[^$=]|=+[^=])*=*)?)?)?\}:XF\$/,inside:{punctuation:{pattern:/[$:{}?.,|]/}},alias:"function"},"directive-inline":{pattern:/\$\w(?:#\d+\+?)?(?:\[[-\w.]+\])?:[-\/\w.]+\$/,inside:{punctuation:{pattern:/\$(?:\w:|C(?:\[|#\d))?|[:{[\]]/,inside:{tag:{pattern:/#\d/}}}},alias:"function"},"directive-block-open":{pattern:/\$\w+:\{|\$\w(?:#\d+\+?)?(?:\[[-\w.]+\])?:[-\w.]+:\{(?:![A-Z]+)?/,inside:{punctuation:{pattern:/\$(?:\w:|C(?:\[|#\d))?|[:{[\]]/,inside:{tag:{pattern:/#\d/}}},attribute:{pattern:/![A-Z]+$/,inside:{punctuation:{pattern:/!/}},alias:"keyword"}},alias:"function"},"directive-block-separator":{pattern:/\}:[-\w.]+:\{/,inside:{punctuation:{pattern:/[:{}]/}},alias:"function"},"directive-block-close":{pattern:/\}:[-\w.]+\$/,inside:{punctuation:{pattern:/[:{}$]/}},alias:"function"}}),n.languages.insertBefore("inside","punctuation",{variable:n.languages.xeora["function-inline"].inside.variable},n.languages.xeora["function-block"]),n.languages.xeoracube=n.languages.xeora}(n)}n.exports=t,t.displayName="xeora",t.aliases=["xeoracube"]}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9748.e711e962.chunk.js b/ydb/core/viewer/monitoring/static/js/9748.e711e962.chunk.js deleted file mode 100644 index 092dbf8969bd..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9748.e711e962.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9748.e711e962.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9748],{59748:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>o,language:()=>r});var o={comments:{lineComment:"'",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"],["addhandler","end addhandler"],["class","end class"],["enum","end enum"],["event","end event"],["function","end function"],["get","end get"],["if","end if"],["interface","end interface"],["module","end module"],["namespace","end namespace"],["operator","end operator"],["property","end property"],["raiseevent","end raiseevent"],["removehandler","end removehandler"],["select","end select"],["set","end set"],["structure","end structure"],["sub","end sub"],["synclock","end synclock"],["try","end try"],["while","end while"],["with","end with"],["using","end using"],["do","loop"],["for","next"]],autoClosingPairs:[{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]},{open:'"',close:'"',notIn:["string","comment"]},{open:"<",close:">",notIn:["string","comment"]}],folding:{markers:{start:new RegExp("^\\s*#Region\\b"),end:new RegExp("^\\s*#End Region\\b")}}},r={defaultToken:"",tokenPostfix:".vb",ignoreCase:!0,brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.array",open:"[",close:"]"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.angle",open:"<",close:">"},{token:"keyword.tag-addhandler",open:"addhandler",close:"end addhandler"},{token:"keyword.tag-class",open:"class",close:"end class"},{token:"keyword.tag-enum",open:"enum",close:"end enum"},{token:"keyword.tag-event",open:"event",close:"end event"},{token:"keyword.tag-function",open:"function",close:"end function"},{token:"keyword.tag-get",open:"get",close:"end get"},{token:"keyword.tag-if",open:"if",close:"end if"},{token:"keyword.tag-interface",open:"interface",close:"end interface"},{token:"keyword.tag-module",open:"module",close:"end module"},{token:"keyword.tag-namespace",open:"namespace",close:"end namespace"},{token:"keyword.tag-operator",open:"operator",close:"end operator"},{token:"keyword.tag-property",open:"property",close:"end property"},{token:"keyword.tag-raiseevent",open:"raiseevent",close:"end raiseevent"},{token:"keyword.tag-removehandler",open:"removehandler",close:"end removehandler"},{token:"keyword.tag-select",open:"select",close:"end select"},{token:"keyword.tag-set",open:"set",close:"end set"},{token:"keyword.tag-structure",open:"structure",close:"end structure"},{token:"keyword.tag-sub",open:"sub",close:"end sub"},{token:"keyword.tag-synclock",open:"synclock",close:"end synclock"},{token:"keyword.tag-try",open:"try",close:"end try"},{token:"keyword.tag-while",open:"while",close:"end while"},{token:"keyword.tag-with",open:"with",close:"end with"},{token:"keyword.tag-using",open:"using",close:"end using"},{token:"keyword.tag-do",open:"do",close:"loop"},{token:"keyword.tag-for",open:"for",close:"next"}],keywords:["AddHandler","AddressOf","Alias","And","AndAlso","As","Async","Boolean","ByRef","Byte","ByVal","Call","Case","Catch","CBool","CByte","CChar","CDate","CDbl","CDec","Char","CInt","Class","CLng","CObj","Const","Continue","CSByte","CShort","CSng","CStr","CType","CUInt","CULng","CUShort","Date","Decimal","Declare","Default","Delegate","Dim","DirectCast","Do","Double","Each","Else","ElseIf","End","EndIf","Enum","Erase","Error","Event","Exit","False","Finally","For","Friend","Function","Get","GetType","GetXMLNamespace","Global","GoSub","GoTo","Handles","If","Implements","Imports","In","Inherits","Integer","Interface","Is","IsNot","Let","Lib","Like","Long","Loop","Me","Mod","Module","MustInherit","MustOverride","MyBase","MyClass","NameOf","Namespace","Narrowing","New","Next","Not","Nothing","NotInheritable","NotOverridable","Object","Of","On","Operator","Option","Optional","Or","OrElse","Out","Overloads","Overridable","Overrides","ParamArray","Partial","Private","Property","Protected","Public","RaiseEvent","ReadOnly","ReDim","RemoveHandler","Resume","Return","SByte","Select","Set","Shadows","Shared","Short","Single","Static","Step","Stop","String","Structure","Sub","SyncLock","Then","Throw","To","True","Try","TryCast","TypeOf","UInteger","ULong","UShort","Using","Variant","Wend","When","While","Widening","With","WithEvents","WriteOnly","Xor"],tagwords:["If","Sub","Select","Try","Class","Enum","Function","Get","Interface","Module","Namespace","Operator","Set","Structure","Using","While","With","Do","Loop","For","Next","Property","Continue","AddHandler","RemoveHandler","Event","RaiseEvent","SyncLock"],symbols:/[=>{o.r(n),o.d(n,{conf:()=>t,language:()=>s});var t={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},s={defaultToken:"",tokenPostfix:".objective-c",keywords:["#import","#include","#define","#else","#endif","#if","#ifdef","#ifndef","#ident","#undef","@class","@defs","@dynamic","@encode","@end","@implementation","@interface","@package","@private","@protected","@property","@protocol","@public","@selector","@synthesize","__declspec","assign","auto","BOOL","break","bycopy","byref","case","char","Class","const","copy","continue","default","do","double","else","enum","extern","FALSE","false","float","for","goto","if","in","int","id","inout","IMP","long","nil","nonatomic","NULL","oneway","out","private","public","protected","readwrite","readonly","register","return","SEL","self","short","signed","sizeof","static","struct","super","switch","typedef","TRUE","true","union","unsigned","volatile","void","while"],decpart:/\d(_?\d)*/,decimal:/0|@decpart/,tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@numbers"},{include:"@strings"},[/[,:;]/,"delimiter"],[/[{}\[\]()<>]/,"@brackets"],[/[a-zA-Z@#]\w*/,{cases:{"@keywords":"keyword","@default":"identifier"}}],[/[<>=\\+\\-\\*\\/\\^\\|\\~,]|and\\b|or\\b|not\\b]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[["\\/\\*","comment","@comment"],["\\/\\/+.*","comment"]],comment:[["\\*\\/","comment","@pop"],[".","comment"]],numbers:[[/0[xX][0-9a-fA-F]*(_?[0-9a-fA-F])*/,"number.hex"],[/@decimal((\.@decpart)?([eE][\-+]?@decpart)?)[fF]*/,{cases:{"(\\d)*":"number",$0:"number.float"}}]],strings:[[/'$/,"string.escape","@popall"],[/'/,"string.escape","@stringBody"],[/"$/,"string.escape","@popall"],[/"/,"string.escape","@dblStringBody"]],stringBody:[[/[^\\']+$/,"string","@popall"],[/[^\\']+/,"string"],[/\\./,"string"],[/'/,"string.escape","@popall"],[/\\$/,"string"]],dblStringBody:[[/[^\\"]+$/,"string","@popall"],[/[^\\"]+/,"string"],[/\\./,"string"],[/"/,"string.escape","@popall"],[/\\$/,"string"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9582.c09a3623.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/97638.a9af06da.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/9582.c09a3623.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/97638.a9af06da.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/97748.5df46a4a.chunk.js b/ydb/core/viewer/monitoring/static/js/97748.5df46a4a.chunk.js new file mode 100644 index 000000000000..dd2151b491f4 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/97748.5df46a4a.chunk.js @@ -0,0 +1 @@ +(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[97748],{97748:function(_,e,t){_.exports=function(_){"use strict";function e(_){return _&&"object"==typeof _&&"default"in _?_:{default:_}}var t=e(_),n={name:"be",weekdays:"\u043d\u044f\u0434\u0437\u0435\u043b\u044e_\u043f\u0430\u043d\u044f\u0434\u0437\u0435\u043b\u0430\u043a_\u0430\u045e\u0442\u043e\u0440\u0430\u043a_\u0441\u0435\u0440\u0430\u0434\u0443_\u0447\u0430\u0446\u0432\u0435\u0440_\u043f\u044f\u0442\u043d\u0456\u0446\u0443_\u0441\u0443\u0431\u043e\u0442\u0443".split("_"),months:"\u0441\u0442\u0443\u0434\u0437\u0435\u043d\u044f_\u043b\u044e\u0442\u0430\u0433\u0430_\u0441\u0430\u043a\u0430\u0432\u0456\u043a\u0430_\u043a\u0440\u0430\u0441\u0430\u0432\u0456\u043a\u0430_\u0442\u0440\u0430\u045e\u043d\u044f_\u0447\u044d\u0440\u0432\u0435\u043d\u044f_\u043b\u0456\u043f\u0435\u043d\u044f_\u0436\u043d\u0456\u045e\u043d\u044f_\u0432\u0435\u0440\u0430\u0441\u043d\u044f_\u043a\u0430\u0441\u0442\u0440\u044b\u0447\u043d\u0456\u043a\u0430_\u043b\u0456\u0441\u0442\u0430\u043f\u0430\u0434\u0430_\u0441\u043d\u0435\u0436\u043d\u044f".split("_"),weekStart:1,weekdaysShort:"\u043d\u0434_\u043f\u043d_\u0430\u0442_\u0441\u0440_\u0447\u0446_\u043f\u0442_\u0441\u0431".split("_"),monthsShort:"\u0441\u0442\u0443\u0434_\u043b\u044e\u0442_\u0441\u0430\u043a_\u043a\u0440\u0430\u0441_\u0442\u0440\u0430\u0432_\u0447\u044d\u0440\u0432_\u043b\u0456\u043f_\u0436\u043d\u0456\u0432_\u0432\u0435\u0440_\u043a\u0430\u0441\u0442_\u043b\u0456\u0441\u0442_\u0441\u043d\u0435\u0436".split("_"),weekdaysMin:"\u043d\u0434_\u043f\u043d_\u0430\u0442_\u0441\u0440_\u0447\u0446_\u043f\u0442_\u0441\u0431".split("_"),ordinal:function(_){return _},formats:{LT:"HH:mm",LTS:"HH:mm:ss",L:"DD.MM.YYYY",LL:"D MMMM YYYY \u0433.",LLL:"D MMMM YYYY \u0433., HH:mm",LLLL:"dddd, D MMMM YYYY \u0433., HH:mm"}};return t.default.locale(n,null,!0),n}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9778.52ad76ce.chunk.js b/ydb/core/viewer/monitoring/static/js/9778.52ad76ce.chunk.js deleted file mode 100644 index 5262728cefe4..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9778.52ad76ce.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9778.52ad76ce.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9778],{49778:(E,T,R)=>{R.r(T),R.d(T,{conf:()=>A,language:()=>I});var A={comments:{lineComment:"--",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"}]},I={defaultToken:"",tokenPostfix:".sql",ignoreCase:!0,brackets:[{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],keywords:["ABORT","ABSOLUTE","ACTION","ADA","ADD","AFTER","ALL","ALLOCATE","ALTER","ALWAYS","ANALYZE","AND","ANY","ARE","AS","ASC","ASSERTION","AT","ATTACH","AUTHORIZATION","AUTOINCREMENT","AVG","BACKUP","BEFORE","BEGIN","BETWEEN","BIT","BIT_LENGTH","BOTH","BREAK","BROWSE","BULK","BY","CASCADE","CASCADED","CASE","CAST","CATALOG","CHAR","CHARACTER","CHARACTER_LENGTH","CHAR_LENGTH","CHECK","CHECKPOINT","CLOSE","CLUSTERED","COALESCE","COLLATE","COLLATION","COLUMN","COMMIT","COMPUTE","CONFLICT","CONNECT","CONNECTION","CONSTRAINT","CONSTRAINTS","CONTAINS","CONTAINSTABLE","CONTINUE","CONVERT","CORRESPONDING","COUNT","CREATE","CROSS","CURRENT","CURRENT_DATE","CURRENT_TIME","CURRENT_TIMESTAMP","CURRENT_USER","CURSOR","DATABASE","DATE","DAY","DBCC","DEALLOCATE","DEC","DECIMAL","DECLARE","DEFAULT","DEFERRABLE","DEFERRED","DELETE","DENY","DESC","DESCRIBE","DESCRIPTOR","DETACH","DIAGNOSTICS","DISCONNECT","DISK","DISTINCT","DISTRIBUTED","DO","DOMAIN","DOUBLE","DROP","DUMP","EACH","ELSE","END","END-EXEC","ERRLVL","ESCAPE","EXCEPT","EXCEPTION","EXCLUDE","EXCLUSIVE","EXEC","EXECUTE","EXISTS","EXIT","EXPLAIN","EXTERNAL","EXTRACT","FAIL","FALSE","FETCH","FILE","FILLFACTOR","FILTER","FIRST","FLOAT","FOLLOWING","FOR","FOREIGN","FORTRAN","FOUND","FREETEXT","FREETEXTTABLE","FROM","FULL","FUNCTION","GENERATED","GET","GLOB","GLOBAL","GO","GOTO","GRANT","GROUP","GROUPS","HAVING","HOLDLOCK","HOUR","IDENTITY","IDENTITYCOL","IDENTITY_INSERT","IF","IGNORE","IMMEDIATE","IN","INCLUDE","INDEX","INDEXED","INDICATOR","INITIALLY","INNER","INPUT","INSENSITIVE","INSERT","INSTEAD","INT","INTEGER","INTERSECT","INTERVAL","INTO","IS","ISNULL","ISOLATION","JOIN","KEY","KILL","LANGUAGE","LAST","LEADING","LEFT","LEVEL","LIKE","LIMIT","LINENO","LOAD","LOCAL","LOWER","MATCH","MATERIALIZED","MAX","MERGE","MIN","MINUTE","MODULE","MONTH","NAMES","NATIONAL","NATURAL","NCHAR","NEXT","NO","NOCHECK","NONCLUSTERED","NONE","NOT","NOTHING","NOTNULL","NULL","NULLIF","NULLS","NUMERIC","OCTET_LENGTH","OF","OFF","OFFSET","OFFSETS","ON","ONLY","OPEN","OPENDATASOURCE","OPENQUERY","OPENROWSET","OPENXML","OPTION","OR","ORDER","OTHERS","OUTER","OUTPUT","OVER","OVERLAPS","PAD","PARTIAL","PARTITION","PASCAL","PERCENT","PIVOT","PLAN","POSITION","PRAGMA","PRECEDING","PRECISION","PREPARE","PRESERVE","PRIMARY","PRINT","PRIOR","PRIVILEGES","PROC","PROCEDURE","PUBLIC","QUERY","RAISE","RAISERROR","RANGE","READ","READTEXT","REAL","RECONFIGURE","RECURSIVE","REFERENCES","REGEXP","REINDEX","RELATIVE","RELEASE","RENAME","REPLACE","REPLICATION","RESTORE","RESTRICT","RETURN","RETURNING","REVERT","REVOKE","RIGHT","ROLLBACK","ROW","ROWCOUNT","ROWGUIDCOL","ROWS","RULE","SAVE","SAVEPOINT","SCHEMA","SCROLL","SECOND","SECTION","SECURITYAUDIT","SELECT","SEMANTICKEYPHRASETABLE","SEMANTICSIMILARITYDETAILSTABLE","SEMANTICSIMILARITYTABLE","SESSION","SESSION_USER","SET","SETUSER","SHUTDOWN","SIZE","SMALLINT","SOME","SPACE","SQL","SQLCA","SQLCODE","SQLERROR","SQLSTATE","SQLWARNING","STATISTICS","SUBSTRING","SUM","SYSTEM_USER","TABLE","TABLESAMPLE","TEMP","TEMPORARY","TEXTSIZE","THEN","TIES","TIME","TIMESTAMP","TIMEZONE_HOUR","TIMEZONE_MINUTE","TO","TOP","TRAILING","TRAN","TRANSACTION","TRANSLATE","TRANSLATION","TRIGGER","TRIM","TRUE","TRUNCATE","TRY_CONVERT","TSEQUAL","UNBOUNDED","UNION","UNIQUE","UNKNOWN","UNPIVOT","UPDATE","UPDATETEXT","UPPER","USAGE","USE","USER","USING","VACUUM","VALUE","VALUES","VARCHAR","VARYING","VIEW","VIRTUAL","WAITFOR","WHEN","WHENEVER","WHERE","WHILE","WINDOW","WITH","WITHIN GROUP","WITHOUT","WORK","WRITE","WRITETEXT","YEAR","ZONE"],operators:["ALL","AND","ANY","BETWEEN","EXISTS","IN","LIKE","NOT","OR","SOME","EXCEPT","INTERSECT","UNION","APPLY","CROSS","FULL","INNER","JOIN","LEFT","OUTER","RIGHT","CONTAINS","FREETEXT","IS","NULL","PIVOT","UNPIVOT","MATCHED"],builtinFunctions:["AVG","CHECKSUM_AGG","COUNT","COUNT_BIG","GROUPING","GROUPING_ID","MAX","MIN","SUM","STDEV","STDEVP","VAR","VARP","CUME_DIST","FIRST_VALUE","LAG","LAST_VALUE","LEAD","PERCENTILE_CONT","PERCENTILE_DISC","PERCENT_RANK","COLLATE","COLLATIONPROPERTY","TERTIARY_WEIGHTS","FEDERATION_FILTERING_VALUE","CAST","CONVERT","PARSE","TRY_CAST","TRY_CONVERT","TRY_PARSE","ASYMKEY_ID","ASYMKEYPROPERTY","CERTPROPERTY","CERT_ID","CRYPT_GEN_RANDOM","DECRYPTBYASYMKEY","DECRYPTBYCERT","DECRYPTBYKEY","DECRYPTBYKEYAUTOASYMKEY","DECRYPTBYKEYAUTOCERT","DECRYPTBYPASSPHRASE","ENCRYPTBYASYMKEY","ENCRYPTBYCERT","ENCRYPTBYKEY","ENCRYPTBYPASSPHRASE","HASHBYTES","IS_OBJECTSIGNED","KEY_GUID","KEY_ID","KEY_NAME","SIGNBYASYMKEY","SIGNBYCERT","SYMKEYPROPERTY","VERIFYSIGNEDBYCERT","VERIFYSIGNEDBYASYMKEY","CURSOR_STATUS","DATALENGTH","IDENT_CURRENT","IDENT_INCR","IDENT_SEED","IDENTITY","SQL_VARIANT_PROPERTY","CURRENT_TIMESTAMP","DATEADD","DATEDIFF","DATEFROMPARTS","DATENAME","DATEPART","DATETIME2FROMPARTS","DATETIMEFROMPARTS","DATETIMEOFFSETFROMPARTS","DAY","EOMONTH","GETDATE","GETUTCDATE","ISDATE","MONTH","SMALLDATETIMEFROMPARTS","SWITCHOFFSET","SYSDATETIME","SYSDATETIMEOFFSET","SYSUTCDATETIME","TIMEFROMPARTS","TODATETIMEOFFSET","YEAR","CHOOSE","COALESCE","IIF","NULLIF","ABS","ACOS","ASIN","ATAN","ATN2","CEILING","COS","COT","DEGREES","EXP","FLOOR","LOG","LOG10","PI","POWER","RADIANS","RAND","ROUND","SIGN","SIN","SQRT","SQUARE","TAN","APP_NAME","APPLOCK_MODE","APPLOCK_TEST","ASSEMBLYPROPERTY","COL_LENGTH","COL_NAME","COLUMNPROPERTY","DATABASE_PRINCIPAL_ID","DATABASEPROPERTYEX","DB_ID","DB_NAME","FILE_ID","FILE_IDEX","FILE_NAME","FILEGROUP_ID","FILEGROUP_NAME","FILEGROUPPROPERTY","FILEPROPERTY","FULLTEXTCATALOGPROPERTY","FULLTEXTSERVICEPROPERTY","INDEX_COL","INDEXKEY_PROPERTY","INDEXPROPERTY","OBJECT_DEFINITION","OBJECT_ID","OBJECT_NAME","OBJECT_SCHEMA_NAME","OBJECTPROPERTY","OBJECTPROPERTYEX","ORIGINAL_DB_NAME","PARSENAME","SCHEMA_ID","SCHEMA_NAME","SCOPE_IDENTITY","SERVERPROPERTY","STATS_DATE","TYPE_ID","TYPE_NAME","TYPEPROPERTY","DENSE_RANK","NTILE","RANK","ROW_NUMBER","PUBLISHINGSERVERNAME","OPENDATASOURCE","OPENQUERY","OPENROWSET","OPENXML","CERTENCODED","CERTPRIVATEKEY","CURRENT_USER","HAS_DBACCESS","HAS_PERMS_BY_NAME","IS_MEMBER","IS_ROLEMEMBER","IS_SRVROLEMEMBER","LOGINPROPERTY","ORIGINAL_LOGIN","PERMISSIONS","PWDENCRYPT","PWDCOMPARE","SESSION_USER","SESSIONPROPERTY","SUSER_ID","SUSER_NAME","SUSER_SID","SUSER_SNAME","SYSTEM_USER","USER","USER_ID","USER_NAME","ASCII","CHAR","CHARINDEX","CONCAT","DIFFERENCE","FORMAT","LEFT","LEN","LOWER","LTRIM","NCHAR","PATINDEX","QUOTENAME","REPLACE","REPLICATE","REVERSE","RIGHT","RTRIM","SOUNDEX","SPACE","STR","STUFF","SUBSTRING","UNICODE","UPPER","BINARY_CHECKSUM","CHECKSUM","CONNECTIONPROPERTY","CONTEXT_INFO","CURRENT_REQUEST_ID","ERROR_LINE","ERROR_NUMBER","ERROR_MESSAGE","ERROR_PROCEDURE","ERROR_SEVERITY","ERROR_STATE","FORMATMESSAGE","GETANSINULL","GET_FILESTREAM_TRANSACTION_CONTEXT","HOST_ID","HOST_NAME","ISNULL","ISNUMERIC","MIN_ACTIVE_ROWVERSION","NEWID","NEWSEQUENTIALID","ROWCOUNT_BIG","XACT_STATE","TEXTPTR","TEXTVALID","COLUMNS_UPDATED","EVENTDATA","TRIGGER_NESTLEVEL","UPDATE","CHANGETABLE","CHANGE_TRACKING_CONTEXT","CHANGE_TRACKING_CURRENT_VERSION","CHANGE_TRACKING_IS_COLUMN_IN_MASK","CHANGE_TRACKING_MIN_VALID_VERSION","CONTAINSTABLE","FREETEXTTABLE","SEMANTICKEYPHRASETABLE","SEMANTICSIMILARITYDETAILSTABLE","SEMANTICSIMILARITYTABLE","FILETABLEROOTPATH","GETFILENAMESPACEPATH","GETPATHLOCATOR","PATHNAME","GET_TRANSMISSION_STATUS"],builtinVariables:["@@DATEFIRST","@@DBTS","@@LANGID","@@LANGUAGE","@@LOCK_TIMEOUT","@@MAX_CONNECTIONS","@@MAX_PRECISION","@@NESTLEVEL","@@OPTIONS","@@REMSERVER","@@SERVERNAME","@@SERVICENAME","@@SPID","@@TEXTSIZE","@@VERSION","@@CURSOR_ROWS","@@FETCH_STATUS","@@DATEFIRST","@@PROCID","@@ERROR","@@IDENTITY","@@ROWCOUNT","@@TRANCOUNT","@@CONNECTIONS","@@CPU_BUSY","@@IDLE","@@IO_BUSY","@@PACKET_ERRORS","@@PACK_RECEIVED","@@PACK_SENT","@@TIMETICKS","@@TOTAL_ERRORS","@@TOTAL_READ","@@TOTAL_WRITE"],pseudoColumns:["$ACTION","$IDENTITY","$ROWGUID","$PARTITION"],tokenizer:{root:[{include:"@comments"},{include:"@whitespace"},{include:"@pseudoColumns"},{include:"@numbers"},{include:"@strings"},{include:"@complexIdentifiers"},{include:"@scopes"},[/[;,.]/,"delimiter"],[/[()]/,"@brackets"],[/[\w@#$]+/,{cases:{"@operators":"operator","@builtinVariables":"predefined","@builtinFunctions":"predefined","@keywords":"keyword","@default":"identifier"}}],[/[<>=!%&+\-*/|~^]/,"operator"]],whitespace:[[/\s+/,"white"]],comments:[[/--+.*/,"comment"],[/\/\*/,{token:"comment.quote",next:"@comment"}]],comment:[[/[^*/]+/,"comment"],[/\*\//,{token:"comment.quote",next:"@pop"}],[/./,"comment"]],pseudoColumns:[[/[$][A-Za-z_][\w@#$]*/,{cases:{"@pseudoColumns":"predefined","@default":"identifier"}}]],numbers:[[/0[xX][0-9a-fA-F]*/,"number"],[/[$][+-]*\d*(\.\d*)?/,"number"],[/((\d+(\.\d*)?)|(\.\d+))([eE][\-+]?\d+)?/,"number"]],strings:[[/N'/,{token:"string",next:"@string"}],[/'/,{token:"string",next:"@string"}]],string:[[/[^']+/,"string"],[/''/,"string"],[/'/,{token:"string",next:"@pop"}]],complexIdentifiers:[[/\[/,{token:"identifier.quote",next:"@bracketedIdentifier"}],[/"/,{token:"identifier.quote",next:"@quotedIdentifier"}]],bracketedIdentifier:[[/[^\]]+/,"identifier"],[/]]/,"identifier"],[/]/,{token:"identifier.quote",next:"@pop"}]],quotedIdentifier:[[/[^"]+/,"identifier"],[/""/,"identifier"],[/"/,{token:"identifier.quote",next:"@pop"}]],scopes:[[/BEGIN\s+(DISTRIBUTED\s+)?TRAN(SACTION)?\b/i,"keyword"],[/BEGIN\s+TRY\b/i,{token:"keyword.try"}],[/END\s+TRY\b/i,{token:"keyword.try"}],[/BEGIN\s+CATCH\b/i,{token:"keyword.catch"}],[/END\s+CATCH\b/i,{token:"keyword.catch"}],[/(BEGIN|CASE)\b/i,{token:"keyword.block"}],[/END\b/i,{token:"keyword.block"}],[/WHEN\b/i,{token:"keyword.choice"}],[/THEN\b/i,{token:"keyword.choice"}]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9796.7afb9492.chunk.js b/ydb/core/viewer/monitoring/static/js/9796.7afb9492.chunk.js deleted file mode 100644 index 1d72be512c44..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9796.7afb9492.chunk.js +++ /dev/null @@ -1 +0,0 @@ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9796],{90053:(e,t,s)=>{s.d(t,{E:()=>h});var a=s(8873),n=s(84476),r=s(24555),o=s(21334),i=s(77506),l=s(90182),d=s(48372);const u=JSON.parse('{"None":"None","15 sec":"15 sec","1 min":"1 min","2 min":"2 min","5 min":"5 min","Refresh":"Refresh"}'),c=(0,d.g4)("ydb-diagnostics-autorefresh-control",{en:u});var m=s(60712);const p=(0,i.cn)("auto-refresh-control");function h({className:e}){const t=(0,l.YQ)(),[s,i]=(0,l.Nt)();return(0,m.jsxs)("div",{className:p(null,e),children:[(0,m.jsx)(n.$,{view:"flat-secondary",onClick:()=>{t(o.F.util.invalidateTags(["All"]))},extraProps:{"aria-label":c("Refresh")},children:(0,m.jsx)(n.$.Icon,{children:(0,m.jsx)(a.A,{})})}),(0,m.jsxs)(r.l,{value:[String(s)],onUpdate:e=>{i(Number(e))},width:85,qa:"ydb-autorefresh-select",children:[(0,m.jsx)(r.l.Option,{value:"0",children:c("None")}),(0,m.jsx)(r.l.Option,{value:"15000",children:c("15 sec")}),(0,m.jsx)(r.l.Option,{value:"60000",children:c("1 min")}),(0,m.jsx)(r.l.Option,{value:"120000",children:c("2 min")}),(0,m.jsx)(r.l.Option,{value:"300000",children:c("5 min")})]})]})}},24543:(e,t,s)=>{s.d(t,{u:()=>o});var a=s(59284),n=s(39238),r=s(60712);const o=({children:e,content:t,className:s,pinOnClick:o,hasArrow:i=!0,placement:l=["top","bottom"],...d})=>{const[u,c]=a.useState(!1),[m,p]=a.useState(!1),h=a.useRef(null);return(0,r.jsxs)(a.Fragment,{children:[(0,r.jsx)(n.z,{anchorRef:h,open:m||u,placement:l,hasArrow:i,onOutsideClick:()=>{p(!1)},...d,children:t}),(0,r.jsx)("span",{className:s,ref:h,onClick:o?()=>{p(!0)}:void 0,onMouseEnter:()=>{c(!0)},onMouseLeave:()=>{c(!1)},children:e})]})}},88226:(e,t,s)=>{s.d(t,{V:()=>d});s(59284);var a=s(77506),n=s(76086),r=s(7187),o=s(90182),i=s(60712);const l=(0,a.cn)("storage-disk-progress-bar");function d({diskAllocatedPercent:e=-1,severity:t,compact:s,faded:a,inactive:d,empty:u,content:c,className:m}){const[p]=(0,o.iK)(n.TJ),h={inverted:p,compact:s,faded:a,empty:u,inactive:d},g=void 0!==t&&(0,r.XY)(t);g&&(h[g.toLocaleLowerCase()]=!0);return(0,i.jsxs)("div",{className:l(h,m),role:"meter","aria-label":"Disk allocated space","aria-valuemin":0,"aria-valuemax":100,"aria-valuenow":e,children:[(()=>{if(s)return(0,i.jsx)("div",{className:l("fill-bar",h),style:{width:"100%"}});const t=p?100-e:e;return e>=0?(0,i.jsx)("div",{className:l("fill-bar",h),style:{width:`${t}%`}}):null})(),c||(!s&&e>=0?(0,i.jsx)("div",{className:l("title"),children:`${Math.round(e)}%`}):null)]})}},53755:(e,t,s)=>{s.d(t,{T:()=>l});var a=s(47665),n=s(77506);const r=(0,s(48372).g4)("ydb-entities-count",{ru:{of:"\u0438\u0437"},en:{of:"of"}});var o=s(60712);const i=(0,n.cn)("ydb-entities-count"),l=({total:e,current:t,label:s,loading:n,className:l})=>{let d="";return s&&(d+=`${s}: `),n?d+="...":(d+=`${t}`,e&&Number(e)!==Number(t)&&(d+=` ${r("of")} ${e}`)),(0,o.jsx)(a.J,{theme:"info",size:"m",className:i(null,l),children:d})}},10508:(e,t,s)=>{s.d(t,{c:()=>c});var a=s(67884),n=s(96873),r=s(54090),o=s(77506),i=s(82015),l=s(33775),d=s(60712);const u=(0,o.cn)("entity-status");function c({status:e=r.m.Grey,name:t="",label:s,path:o,iconPath:c,size:m="s",mode:p="color",showStatus:h=!0,externalLink:g=!1,withLeftTrim:v=!1,hasClipboardButton:f,clipboardButtonAlwaysVisible:S=!1,className:k}){const N=()=>h?(0,d.jsx)(l.k,{className:u("icon"),status:e,size:m,mode:p}):null;return(0,d.jsxs)("div",{className:u(null,k),children:[c?(y=c,(0,d.jsx)(a.N,{target:"_blank",href:y,children:N()})):N(),s&&(0,d.jsx)("span",{title:s,className:u("label",{size:m,state:e.toLowerCase()}),children:s}),(o||t)&&(0,d.jsxs)("div",{className:u("wrapper",{"with-button":f}),children:[(0,d.jsx)("span",{className:u("link",{"with-left-trim":v}),title:t,children:o?g?(0,d.jsx)(a.N,{className:u("name"),href:o,children:t}):(0,d.jsx)(i.E,{className:u("name"),to:o,children:t}):t&&(0,d.jsx)("span",{className:u("name"),children:t})}),f&&(0,d.jsx)("div",{className:u("controls-wrapper",{visible:S}),children:(0,d.jsx)(n.b,{text:t,size:"xs",view:"normal",className:u("clipboard-button",{visible:S})})})]})]});var y}},13096:(e,t,s)=>{s.d(t,{P:()=>u});var a=s(59284),n=s(39238),r=s(43781),o=s.n(r),i=s(77506),l=s(60712);const d=(0,i.cn)("hover-popup"),u=({children:e,popupContent:t,showPopup:s,offset:r,anchorRef:i,onShowPopup:u,onHidePopup:c,placement:m=["top","bottom"],contentClassName:p,delayClose:h=100,delayOpen:g=100})=>{const[v,f]=a.useState(!1),S=a.useRef(null),k=a.useMemo((()=>o()((()=>{f(!0),null===u||void 0===u||u()}),g)),[u,g]),N=a.useCallback((()=>{f(!1),null===c||void 0===c||c()}),[c]),y=a.useMemo((()=>o()(N,h)),[N,h]),b=k,[x,w]=a.useState(!1),[D,I]=a.useState(!1),C=a.useCallback((()=>{w(!0)}),[]),j=a.useCallback((()=>{w(!1)}),[]),P=a.useCallback((()=>{I(!0)}),[]),A=a.useCallback((()=>{I(!1)}),[]),E=a.useCallback((()=>{I(!1),w(!1),N()}),[N]),T=v||s||x||D;return(0,l.jsxs)(a.Fragment,{children:[(0,l.jsx)("span",{ref:S,onMouseEnter:b,onMouseLeave:()=>{k.cancel(),y()},children:e}),(0,l.jsx)(n.z,{contentClassName:d(null,p),anchorRef:i||S,open:T,onMouseEnter:C,onMouseLeave:j,onEscapeKeyDown:E,onBlur:A,placement:m,hasArrow:!0,offset:r||[0,12],children:(0,l.jsx)("div",{onContextMenu:P,children:t})})]})}},73473:(e,t,s)=>{s.d(t,{S:()=>y});var a=s(38501),n=s(40336),r=s(46549),o=s(77506),i=s(76086),l=s(35736),d=s(41650),u=s(13096),c=s(15132),m=s(48372);const p=JSON.parse('{"text_external-consumption":"External Consumption","text_allocator-caches":"Allocator Caches","text_shared-cache":"Shared Cache","text_memtable":"MemTable","text_query-execution":"Query Execution","text_usage":"Usage","text_soft-limit":"Soft Limit","text_hard-limit":"Hard Limit","text_other":"Other"}'),h=(0,m.g4)("ydb-memory-viewer",{en:p});function g(e){return(0,d.kf)(e)?parseFloat(String(e)):void 0}var v=s(60712);const f=1,S=.01*i.J7,k=(0,o.cn)("memory-viewer"),N=(e,t)=>[(0,r.z3)({value:e,size:"gb",withSizeLabel:!1,precision:2}),(0,r.z3)({value:t,size:"gb",withSizeLabel:!0,precision:1})];function y({stats:e,percents:t,formatValues:s,className:o,warningThreshold:i,dangerThreshold:m}){var p;const y=null!==(p=e.AnonRss)&&void 0!==p?p:function(e){const t=g(e.AllocatedMemory)||0,s=g(e.AllocatorCachesMemory)||0;return String(t+s)}(e),b=e.HardLimit,x=(0,a.D)();let w=Math.round(parseFloat(String(y))/parseFloat(String(b))*100)||0;w=w>100?100:w;let D=y,I=b,C="/";t?(D=w+"%",I="",C=""):s&&([D,I]=s(Number(y),Number(b)));const j=function(e,t){const s=[{label:h("text_shared-cache"),key:"SharedCacheConsumption",value:g(e.SharedCacheConsumption),capacity:g(e.SharedCacheLimit),isInfo:!1},{label:h("text_query-execution"),key:"QueryExecutionConsumption",value:g(e.QueryExecutionConsumption),capacity:g(e.QueryExecutionLimit),isInfo:!1},{label:h("text_memtable"),key:"MemTableConsumption",value:g(e.MemTableConsumption),capacity:g(e.MemTableLimit),isInfo:!1},{label:h("text_allocator-caches"),key:"AllocatorCachesMemory",value:g(e.AllocatorCachesMemory),isInfo:!1}],a=s.filter((e=>void 0!==e.value)).reduce(((e,t)=>e+t.value),0),n=Math.max(0,t-a);return s.push({label:h("text_other"),key:"Other",value:n,isInfo:!1}),s.push({label:h("text_external-consumption"),key:"ExternalConsumption",value:g(e.ExternalConsumption),isInfo:!0},{label:h("text_usage"),key:"Usage",value:t,isInfo:!0},{label:h("text_soft-limit"),key:"SoftLimit",value:g(e.SoftLimit),isInfo:!0},{label:h("text_hard-limit"),key:"HardLimit",value:g(e.HardLimit),isInfo:!0}),s.filter((e=>void 0!==e.value))}(e,Number(y)),P=(0,l.w)({fillWidth:w,warningThreshold:i,dangerThreshold:m,colorizeProgress:!0});let A=0;return(0,v.jsx)(u.P,{popupContent:(0,v.jsx)(n.u,{responsive:!0,children:j.map((({label:e,value:t,capacity:s,key:a})=>(0,v.jsx)(n.u.Item,{name:(0,v.jsxs)("div",{className:k("container"),children:[(0,v.jsx)("div",{className:k("legend",{type:a})}),(0,v.jsx)("div",{className:k("name"),children:e})]}),children:s?(0,v.jsx)(c.O,{value:t,capacity:s,formatValues:N,colorizeProgress:!0}):(0,r.z3)({value:t,size:"gb",withSizeLabel:!0,precision:2})},e)))}),children:(0,v.jsx)("div",{className:k({theme:x,status:P},o),children:(0,v.jsxs)("div",{className:k("progress-container"),children:[j.filter((({isInfo:e})=>!e)).map((e=>{if(e.value{s.d(t,{O:()=>f,f:()=>v});var a=s(59284),n=s(78668),r=s(24600),o=s(54090),i=s(7435),l=s(76086),d=s(31684),u=s(90182),c=s(41650),m=s(60073),p=s(25196),h=s(60712);const g=[o.m.Orange,o.m.Red,o.m.Yellow],v=(e,t,s)=>{const{AvailableSize:a,TotalSize:n,State:r,PDiskId:o,NodeId:u,StringifiedId:m,Path:v,Realtime:f,Type:S,Device:k}=e,N=[{label:"PDisk",value:null!==m&&void 0!==m?m:l.Pd},{label:"State",value:r||"not available"},{label:"Type",value:S||"unknown"}];if(u&&N.push({label:"Node Id",value:u}),null!==t&&void 0!==t&&t.Host&&N.push({label:"Host",value:t.Host}),null!==t&&void 0!==t&&t.DC&&N.push({label:"DC",value:t.DC}),v&&N.push({label:"Path",value:v}),(0,c.kf)(n)&&N.push({label:"Available",value:`${(0,c.wb)(a)} of ${(0,c.wb)(n)}`}),f&&g.includes(f)&&N.push({label:"Realtime",value:f}),k&&g.includes(k)&&N.push({label:"Device",value:k}),s&&(0,i.f8)(u)&&(0,i.f8)(o)){const e=(0,d.ar)({nodeId:u,pDiskId:o});N.push({label:"Links",value:(0,h.jsx)(p.K,{title:"Developer UI",url:e})})}return N},f=({data:e})=>{const t=(0,u.N4)(n._5),s=(0,u.N4)(r.K),o=(0,i.f8)(e.NodeId)?null===s||void 0===s?void 0:s.get(e.NodeId):void 0,l=a.useMemo((()=>v(e,o,t)),[e,o,t]);return(0,h.jsx)(m.z_,{title:"PDisk",info:l,size:"s"})}},40427:(e,t,s)=>{s.d(t,{k5:()=>E});var a=s(59284),n=s(89073);const r=s(21334).F.injectEndpoints({endpoints:function(e){return{fetchTableChunk:e.query({queryFn:async({offset:e,limit:t,sortParams:s,filters:a,columnsIds:n,fetchData:r},{signal:o})=>{try{return{data:await r({limit:t,offset:e,filters:a,sortParams:s,columnsIds:n,signal:o})}}catch(i){return{error:i}}},providesTags:["All"]})}}});var o=s(7435),i=s(90182),l=s(44508),d=s(89169);const u=!0;const c=(0,s(77506).cn)("ydb-paginated-table");var m=s(60712);const p=({children:e,className:t,height:s,width:a,align:n="left",resizeable:r})=>(0,m.jsx)("td",{className:c("row-cell",{align:n},t),style:{height:`${s}px`,width:`${a}px`,maxWidth:r?`${a}px`:void 0},children:e}),h=({index:e,columns:t,height:s})=>(0,m.jsx)("tr",{className:c("row",{loading:!0}),children:t.map((t=>{var a;const n=null!==(a=t.resizeable)&&void 0!==a?a:u;return(0,m.jsx)(p,{height:s,width:t.width,align:t.align,className:t.className,resizeable:n,children:(0,m.jsx)(d.E,{className:c("row-skeleton"),style:{width:"80%",height:"50%"}})},`${t.name}${e}`)}))}),g=({row:e,index:t,columns:s,getRowClassName:a,height:n})=>{const r=null===a||void 0===a?void 0:a(e);return(0,m.jsx)("tr",{className:c("row",r),children:s.map((s=>{var a;const r=null!==(a=s.resizeable)&&void 0!==a?a:u;return(0,m.jsx)(p,{height:n,width:s.width,align:s.align,className:s.className,resizeable:r,children:s.render({row:e,index:t})},`${s.name}${t}`)}))})},v=({columns:e,children:t})=>(0,m.jsx)("tr",{className:c("row",{empty:!0}),children:(0,m.jsx)("td",{colSpan:e.length,className:c("td"),children:t})});var f=s(48372);const S=JSON.parse('{"empty":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445"}'),k=(0,f.g4)("ydb-paginated-table",{ru:S,en:{empty:"No data"}});const N=a.memo;const y=N((function({id:e,chunkSize:t,calculatedCount:s,rowHeight:n,columns:d,fetchData:u,tableName:c,filters:p,sortParams:f,getRowClassName:S,renderErrorMessage:N,renderEmptyDataMessage:y,onDataFetched:b,isActive:x}){var w;const[D,I]=a.useState(!0),[C]=(0,i.Nt)(),j={offset:e*t,limit:t,fetchData:u,filters:p,sortParams:f,columnsIds:d.map((e=>e.name)),tableName:c};r.useFetchTableChunkQuery(j,{skip:D||!x,pollingInterval:C});const{currentData:P,error:A}=r.endpoints.fetchTableChunk.useQueryState(j);a.useEffect((()=>{let e=0;return x&&D&&(e=window.setTimeout((()=>{I(!1)}),200)),()=>{window.clearTimeout(e)}}),[x,D]),a.useEffect((()=>{if(P&&x){const{total:e=0,found:t=0}=P;b(e,t)}}),[P,x,b]);const E=(null===P||void 0===P||null===(w=P.data)||void 0===w?void 0:w.length)||s;return(0,m.jsx)("tbody",{id:e.toString(),style:{height:E*n+"px",display:x?"table-row-group":"block"},children:(()=>{var e;if(!x)return null;if(!P){if(A){const e=A;return(0,m.jsx)(v,{columns:d,children:N?N(e):(0,m.jsx)(l.o,{error:e})})}return(0,o._e)(E).map((e=>(0,m.jsx)(h,{columns:d,height:n,index:e},e)))}return null!==(e=P.data)&&void 0!==e&&e.length?P.data.map(((e,t)=>(0,m.jsx)(g,{index:t,row:e,columns:d,height:n,getRowClassName:S},t))):(0,m.jsx)(v,{columns:d,children:y?y():k("empty")})})()})}));function b({minWidth:e,maxWidth:t,getCurrentColumnWidth:s,onResize:n}){const r=a.useRef(null),[o,i]=a.useState(!1);return a.useEffect((()=>{const a=r.current;if(!a)return;let o,l,d;const u=function(e){let t,s=null;return function(...a){t=a,"number"!==typeof s&&(s=requestAnimationFrame((()=>{e(...t),s=null})))}}((s=>{if(x(s),"number"!==typeof o||"number"!==typeof l)return;const a=s.clientX-o,r=function(e,t=40,s=1/0){return Math.max(t,Math.min(e,s))}(l+a,e,t);r!==d&&(d=r,null===n||void 0===n||n(d))})),c=e=>{x(e),void 0!==d&&(null===n||void 0===n||n(d)),i(!1),o=void 0,document.removeEventListener("mousemove",u),document.removeEventListener("mouseup",c)},m=e=>{l=s(),x(e),o=e.clientX,i(!0),document.addEventListener("mousemove",u),document.addEventListener("mouseup",c)};return a.addEventListener("mousedown",m),()=>{a.removeEventListener("mousedown",m),document.removeEventListener("mousemove",u),document.removeEventListener("mouseup",c)}}),[n,e,t,s]),(0,m.jsx)("span",{ref:r,className:c("resize-handler",{resizing:o}),onClick:e=>x(e)})}function x(e){e.preventDefault(),e.stopPropagation()}const w=({order:e})=>(0,m.jsx)("svg",{className:c("sort-icon",{desc:-1===e}),viewBox:"0 0 10 6",width:"10",height:"6",children:(0,m.jsx)("path",{fill:"currentColor",d:"M0 5h10l-5 -5z"})}),D=({sortOrder:e,sortable:t,defaultSortOrder:s})=>t?(0,m.jsx)("span",{className:c("sort-icon-container",{shadow:!e}),children:(0,m.jsx)(w,{order:e||s})}):null,I=({column:e,resizeable:t,sortOrder:s,defaultSortOrder:n,onSort:r,rowHeight:o,onCellMount:i,onCellUnMount:l,onColumnsResize:d})=>{var u;const p=a.useRef(null);a.useEffect((()=>{const e=p.current;return e&&(null===i||void 0===i||i(e)),()=>{e&&(null===l||void 0===l||l(e))}}),[i,l]);const h=a.useCallback((()=>{var e;return null===(e=p.current)||void 0===e?void 0:e.getBoundingClientRect().width}),[]),g=a.useCallback((t=>{null===d||void 0===d||d(e.name,t)}),[d,e.name]),v=null!==(u=e.header)&&void 0!==u?u:e.name,f={height:`${o}px`,width:`${e.width}px`,minWidth:t?`${e.width}px`:void 0,maxWidth:t?`${e.width}px`:void 0};return(0,m.jsxs)("th",{ref:p,className:c("head-cell-wrapper"),style:f,children:[(0,m.jsxs)("div",{className:c("head-cell",{align:e.align,sortable:e.sortable},e.className),onClick:()=>{e.sortable&&(null===r||void 0===r||r(e.name))},children:[(0,m.jsx)("div",{className:c("head-cell-content"),children:v}),(0,m.jsx)(D,{sortOrder:s,sortable:e.sortable,defaultSortOrder:n})]}),t?(0,m.jsx)(b,{maxWidth:e.resizeMaxWidth,minWidth:e.resizeMinWidth,getCurrentColumnWidth:h,onResize:g}):null]})},C=({columns:e,onSort:t,onColumnsResize:s,defaultSortOrder:n=-1,rowHeight:r=41})=>{const[o,i]=a.useState({}),l=e=>{let s={};if(e===o.columnId){if(o.sortOrder&&o.sortOrder!==n)return i(s),void(null===t||void 0===t||t(s));s={sortOrder:1===o.sortOrder?-1:1,columnId:e}}else s={sortOrder:n,columnId:e};null===t||void 0===t||t(s),i(s)};return(0,m.jsxs)(a.Fragment,{children:[(0,m.jsx)("colgroup",{children:e.map((e=>(0,m.jsx)("col",{style:{width:`${e.width}px`}},e.name)))}),(0,m.jsx)("thead",{className:c("head"),children:(0,m.jsx)("tr",{children:e.map((e=>{var t;const a=o.columnId===e.name?o.sortOrder:void 0,i=s&&(null!==(t=e.resizeable)&&void 0!==t?t:u);return(0,m.jsx)(I,{column:e,resizeable:i,sortOrder:a,defaultSortOrder:n,onSort:l,rowHeight:r,onColumnsResize:s},e.name)}))})})]})};var j=s(13847);const P=({limit:e,initialEntitiesCount:t,fetchData:s,filters:r,tableName:o,columns:i,getRowClassName:l,rowHeight:d=41,parentRef:u,initialSortParams:p,onColumnsResize:h,renderControls:g,renderErrorMessage:v,renderEmptyDataMessage:f,containerClassName:S})=>{const k=t||0,N=t||1,[b,x]=a.useState(p),[w,D]=a.useState(k),[I,P]=a.useState(N),[A,E]=a.useState(!0),T=a.useRef(null),U=(({parentRef:e,tableRef:t,totalItems:s,rowHeight:n,chunkSize:r,overscanCount:o=1})=>{const i=a.useMemo((()=>Math.ceil(s/r)),[r,s]),[l,d]=a.useState(0),[u,c]=a.useState(Math.min(o,Math.max(i-1,0))),m=a.useCallback((()=>{const s=null===e||void 0===e?void 0:e.current,a=t.current;if(!s||!a)return null;const l=function(e,t){let s=e,a=0;for(;s&&s!==t;)a+=s.offsetTop,s=s.offsetParent;return a}(a,s),d=s.scrollTop,u=Math.max(d-l,0),c=u+s.clientHeight;return{start:Math.max(Math.floor(u/n/r)-o,0),end:Math.min(Math.floor(c/n/r)+o,Math.max(i-1,0))}}),[e,t,n,r,o,i]),p=a.useCallback((()=>{const e=m();e&&(d(e.start),c(e.end))}),[m]);return a.useEffect((()=>{const t=null===e||void 0===e?void 0:e.current;if(!t)return;const s=(0,j.throttle)(p,100,{leading:!0,trailing:!0});return t.addEventListener("scroll",s),()=>{t.removeEventListener("scroll",s),s.cancel()}}),[p,e]),a.useMemo((()=>{const e=Array(i).fill(!1);for(let t=l;t<=u;t++)e[t]=!0;return e}),[i,l,u])})({parentRef:u,tableRef:T,totalItems:I,rowHeight:d,chunkSize:e}),R=a.useMemo((()=>I?I%e||e:1),[I,e]),M=a.useCallback(((e,t)=>{D(e),P(t),E(!1)}),[]);a.useLayoutEffect((()=>{D(k),P(N),E(!0),null!==u&&void 0!==u&&u.current&&u.current.scrollTo(0,0)}),[r,N,k,u]);const G=()=>(0,m.jsxs)("table",{className:c("table"),children:[(0,m.jsx)(C,{columns:i,onSort:x,onColumnsResize:h}),U.map(((t,a)=>(0,m.jsx)(y,{id:a,calculatedCount:a===U.length-1?R:e,chunkSize:e,rowHeight:d,columns:i,fetchData:s,filters:r,tableName:o,sortParams:b,getRowClassName:l,renderErrorMessage:v,renderEmptyDataMessage:f,onDataFetched:M,isActive:t},a)))]});return(0,m.jsx)("div",{ref:T,className:c(null,S),children:g?(0,m.jsxs)(n.L,{children:[(0,m.jsx)(n.L.Controls,{children:g({inited:!A,totalEntities:w,foundEntities:I})}),(0,m.jsx)(n.L.Table,{children:G()})]}):G()})};var A=s(16819);function E({columnsWidthLSKey:e,columns:t,...s}){const[a,n]=(0,A.a)(e),r=function(e,t){return e.map((e=>{var s;return{...e,width:null!==(s=t[e.name])&&void 0!==s?s:e.width}}))}(t,a);return(0,m.jsx)(P,{columns:r,onColumnsResize:n,containerClassName:c("resizeable-table-container"),...s})}},48295:(e,t,s)=>{s.d(t,{_:()=>u});var a=s(77506),n=s(24543),r=s(80176),o=s(60712);const i=(0,a.cn)("ydb-pool-bar"),l=({data:e={}})=>{const{Usage:t=0}=e,s=Math.min(100*t,100),a=(e=>e>=75?"danger":e>=50&&e<75?"warning":"normal")(s);return(0,o.jsx)(n.u,{className:i({type:a}),content:(0,o.jsx)(r.HG,{data:e,className:i("popup-content")}),children:(0,o.jsx)("div",{style:{height:`${s}%`},className:i("value",{type:a})})})},d=(0,a.cn)("ydb-pools-graph"),u=({pools:e=[]})=>(0,o.jsx)("div",{className:d(),children:e.map(((e,t)=>(0,o.jsx)(l,{data:e},t)))})},15132:(e,t,s)=>{s.d(t,{O:()=>m});var a=s(38501),n=s(77506),r=s(56839),o=s(35736),i=s(41650),l=s(60712);const d=(0,n.cn)("progress-viewer"),u=e=>(0,r.ZV)((0,r.CR)(Number(e),2)),c=(e,t)=>[u(e),u(t)];function m({value:e,capacity:t,formatValues:s=c,percents:n,className:r,size:u="xs",colorizeProgress:m,inverseColorize:p,warningThreshold:h,dangerThreshold:g,hideCapacity:v}){const f=(0,a.D)();let S=Math.round(parseFloat(String(e))/parseFloat(String(t))*100)||0;S=S>100?100:S;let k=e,N=t,y="/";n?(k=S+"%",N="",y=""):s&&([k,N]=s(Number(e),Number(t)));const b=(0,o.w)({fillWidth:S,warningThreshold:h,dangerThreshold:g,colorizeProgress:m,inverseColorize:p});m&&!(0,i.kf)(t)&&(S=100);const x={width:S+"%"};return(0,i.kf)(e)?(0,l.jsxs)("div",{className:d({size:u,theme:f,status:b},r),children:[(0,l.jsx)("div",{className:d("line"),style:x}),(0,l.jsx)("span",{className:d("text"),children:(0,i.kf)(t)&&!v?`${k} ${y} ${N}`:k})]}):(0,l.jsx)("div",{className:`${d({size:u})} ${r} error`,children:"no data"})}},41775:(e,t,s)=>{s.d(t,{v:()=>l});var a=s(59284),n=s(28664),r=s(77506),o=s(60712);const i=(0,r.cn)("ydb-search"),l=({onChange:e,value:t="",width:s,className:r,debounce:l=200,placeholder:d})=>{const[u,c]=a.useState(t),m=a.useRef();a.useEffect((()=>{c((e=>e!==t?t:e))}),[t]);return(0,o.jsx)(n.k,{hasClear:!0,autoFocus:!0,style:{width:s},className:i(null,r),placeholder:d,value:u,onUpdate:t=>{c(t),window.clearTimeout(m.current),m.current=window.setTimeout((()=>{null===e||void 0===e||e(t)}),l)}})}},33775:(e,t,s)=>{s.d(t,{k:()=>m});var a=s(45720),n=s(16929),r=s(71153),o=s(99991),i=s(54090),l=s(77506),d=s(60712);const u=(0,l.cn)("ydb-status-icon"),c={[i.m.Blue]:a.A,[i.m.Yellow]:n.A,[i.m.Orange]:r.A,[i.m.Red]:n.A};function m({status:e=i.m.Grey,size:t="s",mode:s="color",className:a}){const n={state:e.toLowerCase(),size:t};return"icons"===s&&e in c?(0,d.jsx)(o.I,{className:u("status-icon",n,a),data:c[e]}):(0,d.jsx)("div",{className:u("status-color",n,a)})}},19228:(e,t,s)=>{s.d(t,{Q:()=>l});var a=s(89169),n=s(77506),r=s(66781),o=s(60712);const i=(0,n.cn)("table-skeleton"),l=({rows:e=2,delay:t=600,className:s})=>{const[n]=(0,r.y)(t);return(0,o.jsxs)("div",{className:i("wrapper",{hidden:!n},s),children:[(0,o.jsxs)("div",{className:i("row"),children:[(0,o.jsx)(a.E,{className:i("col-1")}),(0,o.jsx)(a.E,{className:i("col-2")}),(0,o.jsx)(a.E,{className:i("col-3")}),(0,o.jsx)(a.E,{className:i("col-4")}),(0,o.jsx)(a.E,{className:i("col-5")})]}),[...new Array(e)].map(((e,t)=>(0,o.jsx)("div",{className:i("row"),children:(0,o.jsx)(a.E,{className:i("col-full")})},`skeleton-row-${t}`)))]})}},89073:(e,t,s)=>{s.d(t,{L:()=>i});var a=s(77506),n=s(19228),r=s(60712);const o=(0,a.cn)("ydb-table-with-controls-layout"),i=({children:e,className:t})=>(0,r.jsx)("div",{className:o(null,t),children:e});i.Controls=function({children:e,className:t}){return(0,r.jsx)("div",{className:o("controls-wrapper"),children:(0,r.jsx)("div",{className:o("controls",t),children:e})})},i.Table=function({children:e,loading:t,className:s}){return t?(0,r.jsx)(n.Q,{className:o("loader")}):(0,r.jsx)("div",{className:o("table",s),children:e})}},64934:(e,t,s)=>{s.d(t,{j:()=>o});var a=s(44433),n=s(78034),r=s(60712);const o=({value:e,onChange:t,className:s})=>(0,r.jsxs)(a.a,{value:e,onUpdate:t,className:s,children:[(0,r.jsx)(a.a.Option,{value:n.cW.All,children:n.DG[n.cW.All]}),(0,r.jsx)(a.a.Option,{value:n.cW.SmallUptime,children:n.DG[n.cW.SmallUptime]})]})},13342:(e,t,s)=>{s.d(t,{U:()=>i});var a=s(47665),n=s(77506),r=s(60712);const o=(0,n.cn)("ydb-usage-label");function i({value:e,overloadThreshold:t=90,theme:s,...n}){return(0,r.jsxs)(a.J,{theme:s,className:o({overload:Number(e)>=t}),...n,children:[e||0,"%"]})}},8809:(e,t,s)=>{s.d(t,{y:()=>P});var a=s(77506),n=s(88226),r=s(13096),o=s(44294),i=s(59284),l=s(47665),d=s(78668),u=s(24600),c=s(54090),m=s(7435),p=s(76086),h=s(31684),g=s(7187),v=s(90182),f=s(41650),S=s(60073),k=s(25196),N=s(96927),y=s(29819),b=s(92459),x=s(56839);function w(e){let t;const s=(0,g.NJ)(e)?e.VDiskSlotId:e.VSlotId;return(0,m.f8)(s)&&(0,m.f8)(e.PDiskId)&&(0,m.f8)(e.NodeId)?t=(0,b.yX)(s,e.PDiskId,e.NodeId):(0,m.f8)(e.NodeId)&&(0,g.NJ)(e)&&(t=(0,b.KY)(b.Ay.node,{id:e.NodeId,activeTab:y.mX},{pdiskId:e.PDiskId,vdiskId:(0,x.U9)(e.VDiskId)})),t}var D=s(60712);const I=(0,a.cn)("vdisk-storage-popup"),C=({data:e})=>{const t=(0,g.NJ)(e),s=(0,v.N4)(d._5),a=i.useMemo((()=>t?((e,t)=>{var s,a,n,r;const{NodeId:o,PDiskId:i,VDiskSlotId:l,StringifiedId:d,VDiskState:u,SatisfactionRank:p,DiskSpace:g,FrontQueues:v,Replicated:S,UnsyncedVDisks:N,AllocatedSize:y,ReadThroughput:b,WriteThroughput:x,StoragePoolName:w}=e,I=[{label:"VDisk",value:d},{label:"State",value:null!==u&&void 0!==u?u:"not available"}];var C,j;if(w&&I.push({label:"StoragePool",value:w}),p&&(null===(s=p.FreshRank)||void 0===s?void 0:s.Flag)!==c.m.Green&&I.push({label:"Fresh",value:null===(C=p.FreshRank)||void 0===C?void 0:C.Flag}),p&&(null===(a=p.LevelRank)||void 0===a?void 0:a.Flag)!==c.m.Green&&I.push({label:"Level",value:null===(j=p.LevelRank)||void 0===j?void 0:j.Flag}),p&&null!==(n=p.FreshRank)&&void 0!==n&&n.RankPercent&&I.push({label:"Fresh",value:p.FreshRank.RankPercent}),p&&null!==(r=p.LevelRank)&&void 0!==r&&r.RankPercent&&I.push({label:"Level",value:p.LevelRank.RankPercent}),g&&g!==c.m.Green&&I.push({label:"Space",value:g}),v&&v!==c.m.Green&&I.push({label:"FrontQueues",value:v}),S||I.push({label:"Replicated",value:"NO"}),N&&I.push({label:"UnsyncVDisks",value:N}),Number(y)&&I.push({label:"Allocated",value:(0,f.wb)(y)}),Number(b)&&I.push({label:"Read",value:(0,f.O4)(b)}),Number(x)&&I.push({label:"Write",value:(0,f.O4)(x)}),t&&(0,m.f8)(o)&&(0,m.f8)(i)&&(0,m.f8)(l)){const e=(0,h.Wg)({nodeId:o,pDiskId:i,vDiskSlotId:l});I.push({label:"Links",value:(0,D.jsx)(k.K,{title:"Developer UI",url:e})})}return I})(e,s):((e,t)=>{const{NodeId:s,PDiskId:a,VSlotId:n,StoragePoolName:r}=e,o=[{label:"State",value:"not available"}];if(r&&o.push({label:"StoragePool",value:r}),o.push({label:"NodeId",value:null!==s&&void 0!==s?s:p.Pd},{label:"PDiskId",value:null!==a&&void 0!==a?a:p.Pd},{label:"VSlotId",value:null!==n&&void 0!==n?n:p.Pd}),t&&(0,m.f8)(s)&&(0,m.f8)(a)&&(0,m.f8)(n)){const e=(0,h.Wg)({nodeId:s,pDiskId:a,vDiskSlotId:n});o.push({label:"Links",value:(0,D.jsx)(k.K,{title:"Developer UI",url:e})})}return o})(e,s)),[e,t,s]),n=(0,v.N4)(u.K),r=(0,m.f8)(e.NodeId)?null===n||void 0===n?void 0:n.get(e.NodeId):void 0,y=i.useMemo((()=>t&&e.PDisk&&(0,N.f)(e.PDisk,r,s)),[e,r,t,s]),b=[];if("Donors"in e&&e.Donors){const t=e.Donors;for(const e of t)b.push({label:"VDisk",value:(0,D.jsx)(o.E,{to:w(e),children:e.StringifiedId})})}return(0,D.jsxs)("div",{className:I(),children:[e.DonorMode&&(0,D.jsx)(l.J,{className:I("donor-label"),children:"Donor"}),(0,D.jsx)(S.z_,{title:"VDisk",info:a,size:"s"}),y&&(0,D.jsx)(S.z_,{title:"PDisk",info:y,size:"s"}),b.length>0&&(0,D.jsx)(S.z_,{title:"Donors",info:b,size:"s"})]})},j=(0,a.cn)("ydb-vdisk-component"),P=({data:e={},compact:t,inactive:s,showPopup:a,onShowPopup:i,onHidePopup:l,progressBarClassName:d,delayClose:u,delayOpen:c})=>{const m=w(e);return(0,D.jsx)(r.P,{showPopup:a,onShowPopup:i,onHidePopup:l,popupContent:(0,D.jsx)(C,{data:e}),offset:[0,5],delayClose:u,delayOpen:c,children:(0,D.jsx)("div",{className:j(),children:(0,D.jsx)(o.E,{to:m,className:j("content"),children:(0,D.jsx)(n.V,{diskAllocatedPercent:e.AllocatedPercent,severity:e.Severity,compact:t,inactive:s,className:d})})})})}},78762:(e,t,s)=>{s.d(t,{pt:()=>ae,SH:()=>X,fr:()=>B,uk:()=>z,Bg:()=>J,Nh:()=>G,ID:()=>$,fR:()=>Y,iX:()=>F,Vz:()=>q,H:()=>Z,_E:()=>M,eT:()=>L,wN:()=>se,kv:()=>_,pH:()=>H,OX:()=>V,ui:()=>te,DH:()=>ee,oz:()=>K,qp:()=>Q,jl:()=>O,Rn:()=>W});var a=s(4557),n=s(40336),r=s(7435),o=s(77506),i=s(76086),l=s(56839),d=s(16439),u=s(41650),c=s(71661),m=s(73473),p=s(63291),h=s(29819),g=s(31684),v=s(78034),f=s(10508),S=s(80176),k=s(60712);const N=({node:e,getNodeRef:t,database:s,statusForIcon:a})=>{if(!e.Host)return(0,k.jsx)("span",{children:"\u2014"});const n="ConnectStatus"===a?e.ConnectStatus:e.SystemState,r=!(0,v.X7)(e);let o;if(t){const s=t(e);o=s?(0,g.Un)(s):void 0}else if(e.NodeId){const t=(0,g.Kx)(e.NodeId);o=(0,g.Un)(t)}const i=r?(0,h.vI)(e.NodeId,{database:null!==s&&void 0!==s?s:e.TenantName}):void 0;return(0,k.jsx)(c.s,{disabled:!r,content:(0,k.jsx)(S.p,{data:e,nodeHref:o}),placement:["top","bottom"],behavior:p.m.Immediate,delayClosing:200,children:(0,k.jsx)(f.c,{name:e.Host,status:n,path:i,hasClipboardButton:!0})})};var y=s(48295),b=s(15132),x=s(52905),w=s(58267);const D=(0,o.cn)("tablets-statistic"),I=({tablets:e=[],database:t,nodeId:s})=>{const a=(e=>e.map((e=>({label:(0,i.bk)(e.Type),type:e.Type,count:e.Count,state:(0,w.P)(e.State)}))).sort(((e,t)=>String(e.label).localeCompare(String(t.label)))))(e);return(0,k.jsx)("div",{className:D(),children:a.map(((e,a)=>{var n;const r=(0,h.vI)(s,{database:t},h.q7),o=`${e.label}: ${e.count}`,i=D("tablet",{state:null===(n=e.state)||void 0===n?void 0:n.toLowerCase()});return(0,k.jsx)(x.N_,{to:r,className:i,children:o},a)}))})};var C=s(41826),j=s(13342),P=s(86782),A=s(31911),E=s(73891);function T(e){return(0,E.Xo)((0,E.Jc)(e,1))}function U(e){const t=(0,E.Jc)(e,1);return(Number(t)<=0?"":"+")+(0,E.Xo)(t)}const R=(0,o.cn)("ydb-nodes-columns");function M(){return{name:P.vg.NodeId,header:"#",width:80,resizeMinWidth:80,render:({row:e})=>e.NodeId,align:a.Ay.RIGHT}}function G({getNodeRef:e,database:t},{statusForIcon:s="SystemState"}={}){return{name:P.vg.Host,header:P.uG.Host,render:({row:a})=>(0,k.jsx)(N,{node:a,getNodeRef:e,database:t,statusForIcon:s}),width:350,align:a.Ay.LEFT}}function L(){return{name:P.vg.NodeName,header:P.uG.NodeName,align:a.Ay.LEFT,render:({row:e})=>e.NodeName||i.Pd,width:200}}function z(){return{name:P.vg.DC,header:P.uG.DC,align:a.Ay.LEFT,render:({row:e})=>e.DC||i.Pd,width:60}}function V(){return{name:P.vg.Rack,header:P.uG.Rack,align:a.Ay.LEFT,render:({row:e})=>e.Rack||i.Pd,width:100}}function W(){return{name:P.vg.Version,header:P.uG.Version,width:200,align:a.Ay.LEFT,render:({row:e})=>(0,k.jsx)(c.s,{content:e.Version,children:e.Version})}}function O(){return{name:P.vg.Uptime,header:P.uG.Uptime,sortAccessor:({StartTime:e})=>e?-e:0,render:({row:e})=>(0,k.jsx)(C.p,{StartTime:e.StartTime,DisconnectTime:e.DisconnectTime}),align:a.Ay.RIGHT,width:120}}function H(){return{name:P.vg.RAM,header:P.uG.RAM,sortAccessor:({MemoryUsed:e=0})=>Number(e),defaultOrder:a.Ay.DESCENDING,render:({row:e})=>{const[t,s]=(0,u.kf)(e.MemoryUsed)&&(0,u.kf)(e.MemoryLimit)?(0,l.j9)(Number(e.MemoryUsed),Number(e.MemoryLimit),"gb",void 0,!0):[0,0];return(0,k.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,k.jsxs)(n.u,{responsive:!0,children:[(0,k.jsx)(n.u.Item,{name:(0,A.A)("field_memory-used"),children:t}),(0,k.jsx)(n.u.Item,{name:(0,A.A)("field_memory-limit"),children:s})]}),children:(0,k.jsx)(b.O,{value:e.MemoryUsed,capacity:e.MemoryLimit,formatValues:(e,t)=>(0,l.j9)(e,t,"gb",void 0,!0),className:R("column-ram"),colorizeProgress:!0,hideCapacity:!0})})},align:a.Ay.LEFT,width:80,resizeMinWidth:40}}function F(){return{name:P.vg.Memory,header:P.uG.Memory,defaultOrder:a.Ay.DESCENDING,render:({row:e})=>e.MemoryStats?(0,k.jsx)(m.S,{formatValues:l.vX,stats:e.MemoryStats}):(0,k.jsx)(b.O,{value:e.MemoryUsed,capacity:e.MemoryLimit,formatValues:l.vX,colorizeProgress:!0}),align:a.Ay.LEFT,width:300,resizeMinWidth:170}}function _(){return{name:P.vg.Pools,header:P.uG.Pools,sortAccessor:({PoolStats:e=[]})=>Math.max(...e.map((({Usage:e})=>Number(e)))),defaultOrder:a.Ay.DESCENDING,render:({row:e})=>e.PoolStats?(0,k.jsx)(y._,{pools:e.PoolStats}):i.Pd,align:a.Ay.LEFT,width:80,resizeMinWidth:60}}function B(){return{name:P.vg.CPU,header:P.uG.CPU,sortAccessor:({PoolStats:e=[]})=>Math.max(...e.map((({Usage:e})=>Number(e)))),defaultOrder:a.Ay.DESCENDING,render:({row:e})=>{if(!e.PoolStats)return i.Pd;let t=(0,u.kf)(e.CoresUsed)&&(0,u.kf)(e.CoresTotal)?e.CoresUsed/e.CoresTotal:void 0;if(void 0===t){let s=0;t=e.PoolStats.reduce(((e,t)=>(s+=Number(t.Threads),e+Number(t.Usage)*Number(t.Threads))),0),t/=s}return(0,k.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,k.jsx)(n.u,{responsive:!0,children:e.PoolStats.map((e=>(0,u.kf)(e.Usage)?(0,k.jsx)(n.u.Item,{name:e.Name,children:(0,S.Qz)("Usage",e.Usage).value},e.Name):null))}),children:(0,k.jsx)(b.O,{className:R("column-cpu"),value:t,capacity:1,colorizeProgress:!0,percents:!0})})},align:a.Ay.LEFT,width:80,resizeMinWidth:40}}function $(){return{name:P.vg.LoadAverage,header:P.uG.LoadAverage,sortAccessor:({LoadAveragePercents:e=[]})=>e[0],defaultOrder:a.Ay.DESCENDING,render:({row:e})=>(0,k.jsx)(b.O,{value:e.LoadAveragePercents&&e.LoadAveragePercents.length>0?e.LoadAveragePercents[0]:void 0,percents:!0,colorizeProgress:!0,capacity:100}),align:a.Ay.LEFT,width:170,resizeMinWidth:170}}function Y(){return{name:P.vg.Load,header:P.uG.Load,sortAccessor:({LoadAveragePercents:e=[]})=>e[0],defaultOrder:a.Ay.DESCENDING,render:({row:e})=>e.LoadAveragePercents&&e.LoadAveragePercents.length>0?(0,k.jsx)(j.U,{value:e.LoadAveragePercents[0].toFixed(),theme:(0,d.f)(e.LoadAveragePercents[0])}):i.Pd,align:a.Ay.LEFT,width:80,resizeMinWidth:70}}function J(){return{name:P.vg.DiskSpaceUsage,header:P.uG.DiskSpaceUsage,render:({row:e})=>(0,r.f8)(e.DiskSpaceUsage)?(0,k.jsx)(j.U,{value:Math.floor(e.DiskSpaceUsage),theme:(0,d.f)(e.DiskSpaceUsage)}):i.Pd,align:a.Ay.LEFT,width:115,resizeMinWidth:75}}function K(){return{name:P.vg.TotalSessions,header:P.uG.TotalSessions,render:({row:e})=>{var t;return null!==(t=e.TotalSessions)&&void 0!==t?t:i.Pd},align:a.Ay.RIGHT,width:100}}function Q({database:e}){return{name:P.vg.Tablets,header:P.uG.Tablets,width:500,resizeMinWidth:500,render:({row:t})=>t.Tablets?(0,k.jsx)(I,{database:null!==e&&void 0!==e?e:t.TenantName,nodeId:t.NodeId,tablets:t.Tablets}):i.Pd,align:a.Ay.LEFT,sortable:!1}}function q(){return{name:P.vg.Missing,header:P.uG.Missing,render:({row:e})=>e.Missing,align:a.Ay.CENTER,defaultOrder:a.Ay.DESCENDING}}function X(){return{name:P.vg.Connections,header:P.uG.Connections,render:({row:e})=>(0,u.kf)(e.Connections)?e.Connections:i.Pd,align:a.Ay.RIGHT,width:130}}function Z(){return{name:P.vg.NetworkUtilization,header:P.uG.NetworkUtilization,render:({row:e})=>{const{NetworkUtilization:t,NetworkUtilizationMin:s=0,NetworkUtilizationMax:a=0}=e;return(0,u.kf)(t)?(0,k.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,k.jsxs)(n.u,{responsive:!0,children:[(0,k.jsx)(n.u.Item,{name:(0,A.A)("sum"),children:(0,l.l9)(t)},"NetworkUtilization"),(0,k.jsx)(n.u.Item,{name:(0,A.A)("min"),children:(0,l.l9)(s)},"NetworkUtilizationMin"),(0,k.jsx)(n.u.Item,{name:(0,A.A)("max"),children:(0,l.l9)(a)},"NetworkUtilizationMax")]}),children:(0,l.l9)(t)}):i.Pd},align:a.Ay.RIGHT,width:110}}function ee(){return{name:P.vg.SendThroughput,header:P.uG.SendThroughput,render:({row:e})=>(0,u.kf)(e.SendThroughput)?(0,u.O4)(e.SendThroughput):i.Pd,align:a.Ay.RIGHT,width:110}}function te(){return{name:P.vg.ReceiveThroughput,header:P.uG.ReceiveThroughput,render:({row:e})=>(0,u.kf)(e.ReceiveThroughput)?(0,u.O4)(e.ReceiveThroughput):i.Pd,align:a.Ay.RIGHT,width:110}}function se(){return{name:P.vg.PingTime,header:P.uG.PingTime,render:({row:e})=>{const{PingTimeUs:t,PingTimeMinUs:s=0,PingTimeMaxUs:a=0}=e;return(0,u.kf)(t)?(0,k.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,k.jsxs)(n.u,{responsive:!0,children:[(0,k.jsx)(n.u.Item,{name:(0,A.A)("avg"),children:T(t)},"PingTimeUs"),(0,k.jsx)(n.u.Item,{name:(0,A.A)("min"),children:T(s)},"PingTimeMinUs"),(0,k.jsx)(n.u.Item,{name:(0,A.A)("max"),children:T(a)},"PingTimeMaxUs")]}),children:T(t)}):i.Pd},align:a.Ay.RIGHT,width:110}}function ae(){return{name:P.vg.ClockSkew,header:P.uG.ClockSkew,render:({row:e})=>{const{ClockSkewUs:t,ClockSkewMinUs:s=0,ClockSkewMaxUs:a=0}=e;return(0,u.kf)(t)?(0,k.jsx)(c.s,{placement:["top","auto"],fullWidth:!0,content:(0,k.jsxs)(n.u,{responsive:!0,children:[(0,k.jsx)(n.u.Item,{name:(0,A.A)("avg"),children:U(t)},"ClockSkewUs"),(0,k.jsx)(n.u.Item,{name:(0,A.A)("min"),children:U(s)},"ClockSkewMinUs"),(0,k.jsx)(n.u.Item,{name:(0,A.A)("max"),children:U(a)},"ClockSkewMaxUs")]}),children:U(t)}):i.Pd},align:a.Ay.RIGHT,width:110}}},86782:(e,t,s)=>{s.d(t,{fN:()=>d,kU:()=>c,kn:()=>l,sp:()=>m,uG:()=>o,vg:()=>r,zO:()=>n});var a=s(31911);const n="nodesTableColumnsWidth",r={NodeId:"NodeId",Host:"Host",Database:"Database",NodeName:"NodeName",DC:"DC",Rack:"Rack",Version:"Version",Uptime:"Uptime",Memory:"Memory",RAM:"RAM",CPU:"CPU",Pools:"Pools",LoadAverage:"LoadAverage",Load:"Load",DiskSpaceUsage:"DiskSpaceUsage",TotalSessions:"TotalSessions",Connections:"Connections",NetworkUtilization:"NetworkUtilization",SendThroughput:"SendThroughput",ReceiveThroughput:"ReceiveThroughput",PingTime:"PingTime",ClockSkew:"ClockSkew",Missing:"Missing",Tablets:"Tablets",PDisks:"PDisks"},o={get NodeId(){return(0,a.A)("node-id")},get Host(){return(0,a.A)("host")},get Database(){return(0,a.A)("database")},get NodeName(){return(0,a.A)("node-name")},get DC(){return(0,a.A)("dc")},get Rack(){return(0,a.A)("rack")},get Version(){return(0,a.A)("version")},get Uptime(){return(0,a.A)("uptime")},get Memory(){return(0,a.A)("memory")},get RAM(){return(0,a.A)("ram")},get Pools(){return(0,a.A)("pools")},get CPU(){return(0,a.A)("cpu")},get LoadAverage(){return(0,a.A)("load-average")},get Load(){return(0,a.A)("load")},get DiskSpaceUsage(){return(0,a.A)("disk-usage")},get TotalSessions(){return(0,a.A)("sessions")},get Connections(){return(0,a.A)("connections")},get NetworkUtilization(){return(0,a.A)("utilization")},get SendThroughput(){return(0,a.A)("send")},get ReceiveThroughput(){return(0,a.A)("receive")},get PingTime(){return(0,a.A)("ping")},get ClockSkew(){return(0,a.A)("skew")},get Missing(){return(0,a.A)("missing")},get Tablets(){return(0,a.A)("tablets")},get PDisks(){return(0,a.A)("pdisks")}},i={get NodeId(){return(0,a.A)("node-id")},get Host(){return(0,a.A)("host")},get NodeName(){return(0,a.A)("node-name")},get Database(){return(0,a.A)("database")},get DiskSpaceUsage(){return(0,a.A)("disk-usage")},get DC(){return(0,a.A)("dc")},get Rack(){return(0,a.A)("rack")},get Missing(){return(0,a.A)("missing")},get Uptime(){return(0,a.A)("uptime")},get Version(){return(0,a.A)("version")},get SystemState(){return(0,a.A)("system-state")},get ConnectStatus(){return(0,a.A)("connect-status")},get NetworkUtilization(){return(0,a.A)("network-utilization")},get ClockSkew(){return(0,a.A)("clock-skew")},get PingTime(){return(0,a.A)("ping-time")}};function l(e){return i[e]}const d={NodeId:["NodeId"],Host:["Host","Rack","Database","SystemState"],Database:["Database"],NodeName:["NodeName"],DC:["DC"],Rack:["Rack"],Version:["Version"],Uptime:["Uptime","DisconnectTime"],Memory:["Memory","MemoryDetailed"],RAM:["Memory"],Pools:["CPU"],CPU:["CPU"],LoadAverage:["LoadAverage"],Load:["LoadAverage"],DiskSpaceUsage:["DiskSpaceUsage"],TotalSessions:["SystemState"],Connections:["Connections"],NetworkUtilization:["NetworkUtilization"],SendThroughput:["SendThroughput"],ReceiveThroughput:["ReceiveThroughput"],PingTime:["PingTime"],ClockSkew:["ClockSkew"],Missing:["Missing"],Tablets:["Tablets","Database"],PDisks:["PDisks"]},u={NodeId:"NodeId",Host:"Host",Database:"Database",NodeName:"NodeName",DC:"DC",Rack:"Rack",Version:"Version",Uptime:"Uptime",Memory:"Memory",RAM:"Memory",CPU:"CPU",Pools:"CPU",LoadAverage:"LoadAverage",Load:"LoadAverage",DiskSpaceUsage:"DiskSpaceUsage",TotalSessions:void 0,Connections:"Connections",NetworkUtilization:"NetworkUtilization",SendThroughput:"SendThroughput",ReceiveThroughput:"ReceiveThroughput",PingTime:"PingTime",ClockSkew:"ClockSkew",Missing:"Missing",Tablets:void 0,PDisks:void 0};function c(e){return u[e]}function m(e){return Boolean(c(e))}},31911:(e,t,s)=>{s.d(t,{A:()=>r});var a=s(48372);const n=JSON.parse('{"node-id":"Node ID","host":"Host","database":"Database","node-name":"Node Name","dc":"DC","rack":"Rack","version":"Version","uptime":"Uptime","memory":"Detailed Memory","ram":"RAM","cpu":"CPU","pools":"Pools","disk-usage":"Disk Usage","tablets":"Tablets","load-average":"Load Average","load":"Load","sessions":"Sessions","missing":"Missing","pdisks":"PDisks","field_memory-used":"Memory used","field_memory-limit":"Memory limit","system-state":"System State","connect-status":"Connect Status","utilization":"Utilization","network-utilization":"Network Utilization","connections":"Connections","clock-skew":"Clock Skew","skew":"Skew","ping-time":"Ping Time","ping":"Ping","send":"Send","receive":"Receive","max":"Max","min":"Min","avg":"Avg","sum":"Sum"}'),r=(0,a.g4)("ydb-nodes-columns",{en:n})},10576:(e,t,s)=>{s.d(t,{E:()=>g});var a=s(59284),n=s(88226),r=s(13096),o=s(44294),i=s(96927),l=s(8809),d=s(92459),u=s(7435),c=s(77506),m=s(3218),p=s(60712);const h=(0,c.cn)("pdisk-storage"),g=({data:e={},vDisks:t,showPopup:s,onShowPopup:c,onHidePopup:g,className:v,progressBarClassName:f,viewContext:S})=>{const{NodeId:k,PDiskId:N}=e,y=(0,u.f8)(k)&&(0,u.f8)(N),b=a.useRef(null);let x;return y&&(x=(0,d.Ck)(N,k)),(0,p.jsxs)("div",{className:h(null,v),ref:b,children:[null!==t&&void 0!==t&&t.length?(0,p.jsx)("div",{className:h("vdisks"),children:t.map((e=>(0,p.jsx)("div",{className:h("vdisks-item"),style:{flexGrow:Number(e.AllocatedSize)||1},children:(0,p.jsx)(l.y,{data:e,inactive:!(0,m.OH)(e,S),compact:!0,delayClose:200,delayOpen:200})},e.StringifiedId)))}):null,(0,p.jsx)(r.P,{showPopup:s,offset:[0,5],anchorRef:b,onShowPopup:c,onHidePopup:g,popupContent:(0,p.jsx)(i.O,{data:e}),delayClose:200,children:(0,p.jsxs)(o.E,{to:x,className:h("content"),children:[(0,p.jsx)(n.V,{diskAllocatedPercent:e.AllocatedPercent,severity:e.Severity,className:f}),(0,p.jsx)("div",{className:h("media-type"),children:e.Type})]})})]})}},99936:(e,t,s)=>{s.d(t,{z:()=>Ve});var a=s(59284),n=s(79553),r=s(98167),o=s(89073),i=s(67028),l=s(10174),d=s(90182),u=s(69775),c=s(98089),m=s(24555),p=s(53755),h=s(41775),g=s(64934),v=s(10360),f=s(370),S=s(86782);const k=["NodeId","Host","Uptime","CPU","RAM","PDisks"],N=["NodeId"],y=["Host","DC","Rack","Version","Uptime","Missing","DiskSpaceUsage"],b=y.map((e=>({value:e,content:(0,S.kn)(e)}))),x=f.z.custom((e=>y.includes(e))).catch(void 0);var w=s(44433);const D={all:"all",missing:"missing",space:"space"},I={groups:"groups",nodes:"nodes"};var C=s(60712);const j={[I.groups]:"Groups",[I.nodes]:"Nodes"},P=({value:e,onChange:t})=>(0,C.jsxs)(w.a,{value:e,onUpdate:t,qa:"storage-type-filter",children:[(0,C.jsx)(w.a.Option,{value:I.groups,children:j[I.groups]}),(0,C.jsx)(w.a.Option,{value:I.nodes,children:j[I.nodes]})]}),A={[D.all]:"All",[D.missing]:"Degraded",[D.space]:"Out of Space"},E=({value:e,onChange:t})=>(0,C.jsxs)(w.a,{value:e,onUpdate:t,qa:"storage-visible-entities-filter",children:[(0,C.jsx)(w.a.Option,{value:D.missing,children:A[D.missing]}),(0,C.jsx)(w.a.Option,{value:D.space,children:A[D.space]}),(0,C.jsx)(w.a.Option,{value:D.all,children:A[D.all]})]});var T=s(48372);const U=JSON.parse('{"groups":"Groups","nodes":"Nodes","controls_groups-search-placeholder":"Group ID, Pool name","controls_nodes-search-placeholder":"Node ID, FQDN","controls_group-by-placeholder":"Group by:","no-nodes":"No such nodes","no-groups":"No such groups"}'),R=(0,T.g4)("ydb-storage",{en:U});var M=s(59109),G=s(44508),L=s(77506);const z=(0,L.cn)("global-storage"),V=e=>403===e.status?(0,C.jsx)(M.O,{position:"left"}):(0,C.jsx)(G.o,{error:e});var W=s(67087);const O=f.z.nativeEnum(D).catch(D.all),H=f.z.nativeEnum(I).catch(I.groups);var F=s(78034);function _(){var e;const[t,s]=(0,W.useQueryParams)({type:W.StringParam,visible:W.StringParam,search:W.StringParam,uptimeFilter:W.StringParam,storageNodesGroupBy:W.StringParam,storageGroupsGroupBy:W.StringParam}),a=H.parse(t.type),n=O.parse(t.visible),r=null!==(e=t.search)&&void 0!==e?e:"",o=F.Bm.parse(t.uptimeFilter),i=v.kY.parse(t.storageGroupsGroupBy),l=x.parse(t.storageNodesGroupBy),d=e=>{s({visible:e},"replaceIn")},u=e=>{s({uptimeFilter:e},"replaceIn")};return{storageType:a,visibleEntities:n,searchValue:r,nodesUptimeFilter:o,storageGroupsGroupByParam:i,storageNodesGroupByParam:l,handleTextFilterChange:e=>{s({search:e||void 0},"replaceIn")},handleVisibleEntitiesChange:d,handleStorageTypeChange:e=>{s({type:e},"replaceIn")},handleUptimeFilterChange:u,handleStorageGroupsGroupByParamChange:e=>{s({storageGroupsGroupBy:e},"replaceIn")},handleStorageNodesGroupByParamChange:e=>{s({storageNodesGroupBy:e},"replaceIn")},handleShowAllGroups:()=>{d("all")},handleShowAllNodes:()=>{d("all"),u(F.cW.All)}}}function B({withTypeSelector:e,withGroupBySelect:t,entitiesCountCurrent:s,entitiesCountTotal:n,entitiesLoading:r,columnsToSelect:o,handleSelectedColumnsUpdate:i}){const{searchValue:l,storageType:d,visibleEntities:g,storageGroupsGroupByParam:f,handleTextFilterChange:S,handleStorageTypeChange:k,handleVisibleEntitiesChange:N,handleStorageGroupsGroupByParamChange:y}=_();return(0,C.jsxs)(a.Fragment,{children:[(0,C.jsx)(h.v,{value:l,onChange:S,placeholder:R("controls_groups-search-placeholder"),className:z("search")}),e&&(0,C.jsx)(P,{value:d,onChange:k}),t?null:(0,C.jsx)(E,{value:g,onChange:N}),(0,C.jsx)(u.O,{popupWidth:200,items:o,showStatus:!0,onUpdate:i,sortable:!1}),t?(0,C.jsxs)(a.Fragment,{children:[(0,C.jsx)(c.E,{variant:"body-2",children:R("controls_group-by-placeholder")}),(0,C.jsx)(m.l,{hasClear:!0,placeholder:"-",width:150,defaultValue:f?[f]:void 0,onUpdate:e=>{y(e[0])},options:v.SE})]}):null,(0,C.jsx)(p.T,{label:R("groups"),loading:r,total:n,current:s})]})}function $({withTypeSelector:e,withGroupBySelect:t,entitiesCountCurrent:s,entitiesCountTotal:n,entitiesLoading:r,columnsToSelect:o,handleSelectedColumnsUpdate:i}){const{searchValue:l,storageType:d,visibleEntities:v,nodesUptimeFilter:f,storageNodesGroupByParam:S,handleTextFilterChange:k,handleStorageTypeChange:N,handleVisibleEntitiesChange:y,handleUptimeFilterChange:x,handleStorageNodesGroupByParamChange:w}=_();return(0,C.jsxs)(a.Fragment,{children:[(0,C.jsx)(h.v,{value:l,onChange:k,placeholder:R("controls_nodes-search-placeholder"),className:z("search")}),e&&(0,C.jsx)(P,{value:d,onChange:N}),t?null:(0,C.jsx)(E,{value:v,onChange:y}),t?null:(0,C.jsx)(g.j,{value:f,onChange:x}),(0,C.jsx)(u.O,{popupWidth:200,items:o,showStatus:!0,onUpdate:i,sortable:!1}),t?(0,C.jsxs)(a.Fragment,{children:[(0,C.jsx)(c.E,{variant:"body-2",children:R("controls_group-by-placeholder")}),(0,C.jsx)(m.l,{hasClear:!0,placeholder:"-",width:150,defaultValue:S?[S]:void 0,onUpdate:e=>{w(e[0])},options:b})]}):null,(0,C.jsx)(p.T,{label:R("nodes"),loading:r,total:n,current:s})]})}var Y=s(40427),J=s(84476),K=s(7889),Q=s(78524);const q=JSON.parse('{"default_message":"Everything is fine!","default_button_label":"Show All"}'),X=JSON.parse('{"default_message":"\u0412\u0441\u0451 \u0432 \u043f\u043e\u0440\u044f\u0434\u043a\u0435!","default_button_label":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435"}'),Z=(0,T.g4)("ydb-storage-empty-filter",{ru:X,en:q}),ee=({title:e,message:t=Z("default_message"),showAll:s=Z("default_button_label"),onShowAll:a})=>(0,C.jsx)(K.p,{image:(0,C.jsx)(Q.v,{name:"thumbsUp"}),position:"left",title:e,description:t,actions:a&&[(0,C.jsx)(J.$,{onClick:a,children:s},"show-all")]});var te=s(61456);const se=({visibleEntities:e,onShowAll:t})=>{let s;return e===D.space&&(s=(0,te.A)("empty.out_of_space")),e===D.missing&&(s=(0,te.A)("empty.degraded")),s?(0,C.jsx)(ee,{title:s,showAll:(0,te.A)("show_all"),onShowAll:t}):null};var ae=s(16029),ne=s(69464),re=s(40781);const oe=({columns:e,database:t,nodeId:s,groupId:n,pDiskId:o,filterGroup:l,filterGroupBy:d,searchValue:u,visibleEntities:c,onShowAll:m,parentRef:p,renderControls:h,renderErrorMessage:g,initialEntitiesCount:f})=>{const S=(0,i.Pm)(),k=(0,i.YA)(),N=(y=k,a.useCallback((async e=>{const{limit:t,offset:s,sortParams:a,filters:n,columnsIds:r}=e,{sortOrder:o,columnId:i}=null!==a&&void 0!==a?a:{},{searchValue:l,visibleEntities:d,database:u,nodeId:c,groupId:m,pDiskId:p,filterGroup:h,filterGroupBy:g}=null!==n&&void 0!==n?n:{},f=(0,v.GP)(i),S=f?(0,ne.T)(f,o):void 0,k=(0,re.R)(r,v.YX),{groups:N,found:b,total:x}=await(0,ae.t)({limit:t,offset:s,sort:S,filter:l,with:d,database:u,nodeId:c,groupId:m,pDiskId:p,filter_group:h,filter_group_by:g,fieldsRequired:k,shouldUseGroupsHandler:y});return{data:N||[],found:b||0,total:x||0}}),[y]));var y;const b=a.useMemo((()=>({searchValue:u,visibleEntities:c,database:t,nodeId:s,groupId:n,pDiskId:o,filterGroup:l,filterGroupBy:d})),[u,c,t,s,n,o,l,d]);return(0,C.jsx)(r.r,{loading:!S,children:(0,C.jsx)(Y.k5,{columnsWidthLSKey:v.qK,parentRef:p,columns:e,fetchData:N,limit:50,initialEntitiesCount:f,renderControls:h,renderErrorMessage:g,renderEmptyDataMessage:()=>c!==D.all?(0,C.jsx)(se,{onShowAll:m,visibleEntities:c}):(0,te.A)("empty.default"),filters:b,tableName:"storage-groups"})})};var ie=s(43951),le=s(20831);function de({visibleEntities:e,viewContext:t}){const s=a.useMemo((()=>(0,le.J)({viewContext:t})),[t]),n=a.useMemo((()=>e===D.missing?[...v.LO,v.UW.Degraded]:e===D.space?[...v.LO,v.UW.DiskSpace]:v.LO),[e]);return(0,ie.K)(s,v.zY,v.H6,v.hu,n)}var ue=s(71708),ce=s(62710);function me(e){const{storageGroupsGroupByParam:t,visibleEntities:s,handleShowAllGroups:n}=_(),o=(0,i.Pm)(),l=(0,i.SA)();a.useEffect((()=>{l&&"all"!==s&&n()}),[n,l,s]);return(0,C.jsx)(r.r,{loading:!o,children:l&&t?(0,C.jsx)(he,{...e}):(0,C.jsx)(pe,{...e})})}function pe({database:e,nodeId:t,groupId:s,pDiskId:a,viewContext:n,parentRef:r,initialEntitiesCount:o}){const{searchValue:l,visibleEntities:d,handleShowAllGroups:u}=_(),c=(0,i.SA)(),{columnsToShow:m,columnsToSelect:p,setColumns:h}=de({visibleEntities:d,viewContext:n});return(0,C.jsx)(oe,{database:e,nodeId:t,groupId:s,pDiskId:a,searchValue:l,visibleEntities:d,onShowAll:u,parentRef:r,renderControls:({totalEntities:e,foundEntities:t,inited:s})=>(0,C.jsx)(B,{withTypeSelector:!0,withGroupBySelect:c,entitiesCountCurrent:t,entitiesCountTotal:e,entitiesLoading:!s,columnsToSelect:p,handleSelectedColumnsUpdate:h}),renderErrorMessage:V,columns:m,initialEntitiesCount:o})}function he({database:e,nodeId:t,groupId:s,pDiskId:a,parentRef:r,viewContext:i}){const[u]=(0,d.Nt)(),{searchValue:c,storageGroupsGroupByParam:m,visibleEntities:p,handleShowAllGroups:h}=_(),{columnsToShow:g,columnsToSelect:v,setColumns:f}=de({visibleEntities:p,viewContext:i}),{currentData:S,isFetching:k,error:N}=l.S.useGetStorageGroupsInfoQuery({database:e,with:"all",nodeId:t,groupId:s,pDiskId:a,filter:c,shouldUseGroupsHandler:!0,group:m},{pollingInterval:u}),y=void 0===S&&k,{tableGroups:b,found:x=0,total:w=0}=S||{},{expandedGroups:D,setIsGroupExpanded:I}=(0,ce.$)(b);return(0,C.jsxs)(o.L,{children:[(0,C.jsx)(o.L.Controls,{children:(0,C.jsx)(B,{withTypeSelector:!0,withGroupBySelect:!0,entitiesCountCurrent:x,entitiesCountTotal:w,entitiesLoading:y,columnsToSelect:v,handleSelectedColumnsUpdate:f})}),N?(0,C.jsx)(n.o,{error:N}):null,(0,C.jsx)(o.L.Table,{loading:y,className:z("groups-wrapper"),children:null!==b&&void 0!==b&&b.length?b.map((({name:n,count:o})=>{const i=D[n];return(0,C.jsx)(ue.Q,{title:n,count:o,entityName:R("groups"),expanded:i,onIsExpandedChange:I,children:(0,C.jsx)(oe,{database:e,parentRef:r,nodeId:t,groupId:s,pDiskId:a,filterGroup:n,filterGroupBy:m,searchValue:c,visibleEntities:"all",onShowAll:h,renderErrorMessage:V,columns:g,initialEntitiesCount:o})},n)})):R("no-groups")})]})}var ge=s(67157),ve=s(71294);const fe=JSON.parse('{"empty.default":"No such nodes","empty.out_of_space":"No nodes with out of space errors","empty.degraded":"No degraded nodes","empty.small_uptime":"No nodes with uptime < 1h","empty.several_filters":"No nodes match current filters combination","show_all":"Show all nodes"}'),Se=JSON.parse('{"empty.default":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432","empty.out_of_space":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432, \u0432 \u043a\u043e\u0442\u043e\u0440\u044b\u0445 \u043a\u043e\u043d\u0447\u0430\u0435\u0442\u0441\u044f \u043c\u0435\u0441\u0442\u043e","empty.degraded":"\u041d\u0435\u0442 \u0434\u0435\u0433\u0440\u0430\u0434\u0438\u0440\u043e\u0432\u0430\u0432\u0448\u0438\u0445 \u0443\u0437\u043b\u043e\u0432","empty.small_uptime":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432 \u0441 uptime < 1h","empty.several_filters":"\u041d\u0435\u0442 \u0443\u0437\u043b\u043e\u0432, \u043f\u043e\u0434\u0445\u043e\u0434\u044f\u0449\u0438\u0445 \u043f\u043e\u0434 \u0442\u0435\u043a\u0443\u0449\u0438\u0435 \u0444\u0438\u043b\u044c\u0442\u0440\u044b","show_all":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435 \u0443\u0437\u043b\u044b"}'),ke=(0,T.g4)("ydb-storage-nodes",{ru:Se,en:fe}),Ne=({visibleEntities:e,nodesUptimeFilter:t,onShowAll:s})=>{let a;return e===D.space&&(a=ke("empty.out_of_space")),e===D.missing&&(a=ke("empty.degraded")),t===F.cW.SmallUptime&&(a=ke("empty.small_uptime")),e!==D.all&&t!==F.cW.All&&(a=ke("empty.several_filters")),a?(0,C.jsx)(ee,{title:a,showAll:ke("show_all"),onShowAll:s}):null};var ye=s(11905);const be=async e=>{const{type:t="static",storage:s=!0,limit:a,offset:n,sortParams:r,filters:o,columnsIds:i}=e,{searchValue:l,nodesUptimeFilter:d,visibleEntities:u,database:c,nodeId:m,groupId:p,filterGroup:h,filterGroupBy:g}=null!==o&&void 0!==o?o:{},{sortOrder:v,columnId:f}=null!==r&&void 0!==r?r:{},k=(0,S.kU)(f),N=k?(0,ne.T)(k,v):void 0,y=(0,re.R)(i,S.fN),b=await window.api.viewer.getNodes({type:t,storage:s,limit:a,offset:n,sort:N,filter:l,uptime:(0,F.Fo)(d),with:u,database:c,node_id:m,group_id:p,filter_group:h,filter_group_by:g,fieldsRequired:y}),x=(0,ye.rz)(b);return{data:x.nodes||[],found:x.found||0,total:x.total||0}},xe=(0,L.cn)("ydb-storage-nodes"),we=e=>xe("node",{unavailable:(0,F.X7)(e)}),De=({columns:e,database:t,nodeId:s,groupId:n,filterGroup:r,filterGroupBy:o,searchValue:i,visibleEntities:l,nodesUptimeFilter:d,onShowAll:u,parentRef:c,renderControls:m,renderErrorMessage:p,initialEntitiesCount:h})=>{const g=a.useMemo((()=>({searchValue:i,visibleEntities:l,nodesUptimeFilter:d,database:t,nodeId:s,groupId:n,filterGroup:r,filterGroupBy:o})),[i,l,d,t,s,n,r,o]);return(0,C.jsx)(Y.k5,{columnsWidthLSKey:"storageNodesColumnsWidth",parentRef:c,columns:e,fetchData:be,rowHeight:51,limit:50,initialEntitiesCount:h,renderControls:m,renderErrorMessage:p,renderEmptyDataMessage:()=>l!==D.all||d!==F.cW.All?(0,C.jsx)(Ne,{onShowAll:u,nodesUptimeFilter:d,visibleEntities:l}):ke("empty.default"),getRowClassName:we,filters:g,tableName:"storage-nodes"})};var Ie=s(4557),Ce=s(78762),je=s(10576);const Pe=(0,L.cn)("ydb-storage-nodes-columns"),Ae="--maximum-slots",Ee="--maximum-disks",Te=({viewContext:e})=>({name:S.vg.PDisks,header:S.uG.PDisks,className:Pe("pdisks-column"),render:({row:t})=>{var s;const a={[Ae]:t.MaximumSlotsPerDisk,[Ee]:t.MaximumDisksPerNode};return(0,C.jsx)("div",{className:Pe("pdisks-wrapper"),style:a,children:null===(s=t.PDisks)||void 0===s?void 0:s.map((s=>{var a;const n=null===(a=t.VDisks)||void 0===a?void 0:a.filter((e=>e.PDiskId===s.PDiskId));return(0,C.jsx)("div",{className:Pe("pdisks-item"),children:(0,C.jsx)(je.E,{data:s,vDisks:n,viewContext:e})},s.PDiskId)}))})},align:Ie.Ay.CENTER,sortable:!1,resizeable:!1});function Ue({visibleEntities:e,database:t,additionalNodesProps:s,viewContext:n}){const r=a.useMemo((()=>(({database:e,additionalNodesProps:t,viewContext:s})=>{const a=null===t||void 0===t?void 0:t.getNodeRef;return[(0,Ce._E)(),(0,Ce.Nh)({getNodeRef:a,database:e}),(0,Ce.eT)(),(0,Ce.uk)(),(0,Ce.OX)(),(0,Ce.jl)(),(0,Ce.fr)(),(0,Ce.kv)(),(0,Ce.pH)(),(0,Ce.iX)(),(0,Ce.Bg)(),(0,Ce.Rn)(),(0,Ce.Vz)(),Te({viewContext:s})].map((e=>({...e,sortable:(0,S.sp)(e.name)})))})({database:t,additionalNodesProps:s,viewContext:n})),[t,s,n]),o=a.useMemo((()=>e===D.missing?[...N,S.vg.Missing]:N),[e]);return(0,ie.K)(r,"storageNodesSelectedColumns",S.uG,k,o)}const Re=e=>{const{storageNodesGroupByParam:t,visibleEntities:s,nodesUptimeFilter:n,handleShowAllNodes:o}=_(),l=(0,i.Pm)(),d=(0,i.Ye)();a.useEffect((()=>{!d||"all"===s&&n===F.cW.All||o()}),[o,n,d,s]);return(0,C.jsx)(r.r,{loading:!l,children:d&&t?(0,C.jsx)(Ge,{...e}):(0,C.jsx)(Me,{...e})})};function Me({database:e,nodeId:t,groupId:s,viewContext:a,parentRef:n,initialEntitiesCount:r}){const{searchValue:o,visibleEntities:l,nodesUptimeFilter:d,handleShowAllNodes:u}=_(),c=(0,i.Ye)(),{columnsToShow:m,columnsToSelect:p,setColumns:h}=Le({database:e,viewContext:a});return(0,C.jsx)(De,{database:e,nodeId:t,groupId:s,searchValue:o,visibleEntities:l,nodesUptimeFilter:d,onShowAll:u,parentRef:n,renderControls:({totalEntities:e,foundEntities:t,inited:s})=>(0,C.jsx)($,{withTypeSelector:!0,withGroupBySelect:c,entitiesCountCurrent:t,entitiesCountTotal:e,entitiesLoading:!s,columnsToSelect:p,handleSelectedColumnsUpdate:h}),renderErrorMessage:V,columns:m,initialEntitiesCount:r})}function Ge({database:e,groupId:t,nodeId:s,viewContext:a,parentRef:n}){const[r]=(0,d.Nt)(),{searchValue:i,storageNodesGroupByParam:u,handleShowAllNodes:c}=_(),{columnsToShow:m,columnsToSelect:p,setColumns:h}=Le({database:e,viewContext:a}),{currentData:g,isFetching:v,error:f}=l.S.useGetStorageNodesInfoQuery({database:e,with:"all",filter:i,node_id:s,group_id:t,group:u},{pollingInterval:r}),S=void 0===g&&v,{tableGroups:k,found:N=0,total:y=0}=g||{},{expandedGroups:b,setIsGroupExpanded:x}=(0,ce.$)(k);return(0,C.jsxs)(o.L,{children:[(0,C.jsx)(o.L.Controls,{children:(0,C.jsx)($,{withTypeSelector:!0,withGroupBySelect:!0,entitiesCountCurrent:N,entitiesCountTotal:y,entitiesLoading:S,columnsToSelect:p,handleSelectedColumnsUpdate:h})}),f?(0,C.jsx)(G.o,{error:f}):null,(0,C.jsx)(o.L.Table,{loading:S,className:z("groups-wrapper"),children:null!==k&&void 0!==k&&k.length?k.map((({name:a,count:r})=>{const o=b[a];return(0,C.jsx)(ue.Q,{title:a,count:r,entityName:R("nodes"),expanded:o,onIsExpandedChange:x,children:(0,C.jsx)(De,{database:e,parentRef:n,nodeId:s,groupId:t,searchValue:i,visibleEntities:"all",nodesUptimeFilter:F.cW.All,onShowAll:c,filterGroup:a,filterGroupBy:u,renderErrorMessage:V,columns:m,initialEntitiesCount:r})},a)})):R("no-nodes")})]})}function Le({database:e,viewContext:t}){const{balancer:s}=(0,ge.Zd)(),{additionalNodesProps:a}=(0,ve.B)({balancer:s}),{visibleEntities:n}=_();return Ue({additionalNodesProps:a,visibleEntities:n,database:e,viewContext:t})}var ze=s(3218);const Ve=e=>{const{storageType:t}=_();return"nodes"===t?(0,C.jsx)(Re,{initialEntitiesCount:(0,ze.b0)(e.viewContext),...e}):(0,C.jsx)(me,{initialEntitiesCount:(0,ze.QQ)(e.viewContext),...e})}},20831:(e,t,s)=>{s.d(t,{J:()=>oe,k:()=>re});var a=s(79879),n=s(4557),r=s(63291),o=s(47665),i=s(84375),l=s(99991),d=s(71661),u=s(44294),c=s(33775),m=s(13342),p=s(92459),h=s(7435),g=s(77506),v=s(76086),f=s(56839),S=s(16439),k=s(73891),N=s(41650),y=s(59284),b=s(69033),x=s(87184),w=s(8809),D=s(10576),I=s(3218),C=s(60712);const j=(0,g.cn)("ydb-storage-disks");function P({vDisks:e=[],viewContext:t}){const[s,a]=y.useState(),n=(0,I.Ep)(e),{theme:{spaceBaseSize:r}}=(0,b.L)();if(!e.length)return null;const o=(300-r*(e.length-1))/e.length;return(0,C.jsxs)("div",{className:j(null),children:[(0,C.jsx)(x.s,{direction:"row",gap:1,grow:!0,style:{width:300},children:null===e||void 0===e?void 0:e.map((e=>(0,C.jsx)(A,{vDisk:e,inactive:!(0,I.OH)(e,t),highlightedVDisk:s,setHighlightedVDisk:a,unavailableVDiskWidth:o},e.StringifiedId)))}),(0,C.jsx)("div",{className:j("pdisks-wrapper"),children:null===e||void 0===e?void 0:e.map(((e,t)=>{var r;return(0,C.jsx)(E,{vDisk:e,highlightedVDisk:s,setHighlightedVDisk:a,withDCMargin:n.includes(t)},null===e||void 0===e||null===(r=e.PDisk)||void 0===r?void 0:r.StringifiedId)}))})]})}function A({vDisk:e,highlightedVDisk:t,inactive:s,setHighlightedVDisk:a,unavailableVDiskWidth:n}){const r={...e,PDisk:void 0},o=e.StringifiedId,i=(0,h.f8)(r.AllocatedSize)?void 0:n,l=Number(r.AllocatedSize)||1;return(0,C.jsx)("div",{style:{flexGrow:l,minWidth:i},className:j("vdisk-item"),children:(0,C.jsx)(w.y,{data:r,compact:!0,inactive:s,showPopup:t===o,onShowPopup:()=>a(o),onHidePopup:()=>a(void 0),progressBarClassName:j("vdisk-progress-bar")})})}function E({vDisk:e,highlightedVDisk:t,setHighlightedVDisk:s,withDCMargin:a}){const n=e.StringifiedId;return e.PDisk?(0,C.jsx)(D.E,{className:j("pdisk-item",{"with-dc-margin":a}),progressBarClassName:j("pdisk-progress-bar"),data:e.PDisk,showPopup:t===n,onShowPopup:()=>s(n),onHidePopup:()=>s(void 0)}):null}var T=s(7187);const U="--ydb-stack-level",R=(0,g.cn)("stack"),M=({children:e,className:t})=>(0,C.jsx)("div",{className:R(null,t),children:y.Children.map(e,((e,t)=>y.isValidElement(e)?(0,C.jsx)("div",{className:R("layer"),style:{[U]:t},children:e}):null))});function G({data:e,className:t,stackClassName:s,...a}){const{Donors:n,...r}=e||{},o=n&&n.length>0?(0,C.jsxs)(M,{className:s,children:[(0,C.jsx)(w.y,{data:r,...a}),n.map((e=>{const t=(0,T.NJ)(e);return(0,C.jsx)(w.y,{data:e,...a},(0,f.U9)(t?e.VDiskId:e))}))]}):(0,C.jsx)(w.y,{data:e,...a});return(0,C.jsx)("div",{className:t,children:o})}const L=(0,g.cn)("ydb-storage-vdisks");function z({vDisks:e,viewContext:t}){const s=(0,I.Ep)(e);return(0,C.jsx)("div",{className:L("wrapper"),children:null===e||void 0===e?void 0:e.map(((e,a)=>(0,C.jsx)(G,{data:e,inactive:!(0,I.OH)(e,t),className:L("item",{"with-dc-margin":s.includes(a)})},e.StringifiedId)))})}var V=s(61456),W=s(10360);const O=(0,g.cn)("ydb-storage-groups-columns"),H={name:W.UW.PoolName,header:W.H6.PoolName,width:250,render:({row:e})=>e.PoolName?(0,C.jsx)(d.s,{content:e.PoolName,placement:["right"],behavior:r.m.Immediate,className:O("pool-name-wrapper"),children:(0,C.jsx)("span",{className:O("pool-name"),children:e.PoolName})}):v.Pd,align:n.Ay.LEFT},F={name:W.UW.MediaType,header:W.H6.MediaType,width:100,resizeMinWidth:100,align:n.Ay.LEFT,render:({row:e})=>(0,C.jsxs)("div",{children:[(0,C.jsx)(o.J,{children:e.MediaType||"\u2014"}),"\xa0",e.Encryption&&(0,C.jsx)(i.A,{content:(0,V.A)("encrypted"),placement:"right",behavior:r.m.Immediate,children:(0,C.jsx)(o.J,{children:(0,C.jsx)(l.I,{data:a.A,size:18})})})]}),sortable:!1},_={name:W.UW.Erasure,header:W.H6.Erasure,width:100,sortAccessor:e=>e.ErasureSpecies,render:({row:e})=>e.ErasureSpecies?e.ErasureSpecies:"-",align:n.Ay.LEFT},B={name:W.UW.Degraded,header:W.H6.Degraded,width:110,resizeMinWidth:110,render:({row:e})=>e.Degraded?(0,C.jsxs)(o.J,{theme:(0,I.k_)(e),children:["Degraded: ",e.Degraded]}):"-",align:n.Ay.LEFT,defaultOrder:n.Ay.DESCENDING},$={name:W.UW.State,header:W.H6.State,width:150,render:({row:e})=>{var t;return null!==(t=e.State)&&void 0!==t?t:v.Pd},align:n.Ay.LEFT,defaultOrder:n.Ay.DESCENDING},Y={name:W.UW.Usage,header:W.H6.Usage,width:85,resizeMinWidth:75,render:({row:e})=>(0,h.f8)(e.Usage)?(0,C.jsx)(m.U,{value:Math.floor(e.Usage),theme:(0,S.f)(e.Usage)}):v.Pd,align:n.Ay.LEFT},J={name:W.UW.DiskSpaceUsage,header:W.H6.DiskSpaceUsage,width:115,resizeMinWidth:75,render:({row:e})=>(0,h.f8)(e.DiskSpaceUsage)?(0,C.jsx)(m.U,{value:Math.floor(e.DiskSpaceUsage),theme:(0,S.f)(e.DiskSpaceUsage)}):v.Pd,align:n.Ay.LEFT},K={name:W.UW.GroupId,header:W.H6.GroupId,width:130,render:({row:e})=>e.GroupId?(0,C.jsx)(u.E,{className:O("group-id"),to:(0,p._g)(e.GroupId),children:e.GroupId}):"-",sortAccessor:e=>Number(e.GroupId),align:n.Ay.RIGHT},Q={name:W.UW.Used,header:W.H6.Used,width:100,render:({row:e})=>(0,N.wb)(e.Used,!0),align:n.Ay.RIGHT},q={name:W.UW.Limit,header:W.H6.Limit,width:100,render:({row:e})=>(0,N.wb)(e.Limit),align:n.Ay.RIGHT},X={name:W.UW.DiskSpace,header:W.H6.DiskSpace,width:70,render:({row:e})=>(0,C.jsx)(c.k,{status:e.DiskSpace}),align:n.Ay.CENTER},Z={name:W.UW.Read,header:W.H6.Read,width:100,render:({row:e})=>e.Read?(0,N.O4)(e.Read):"-",align:n.Ay.RIGHT},ee={name:W.UW.Write,header:W.H6.Write,width:100,render:({row:e})=>e.Write?(0,N.O4)(e.Write):"-",align:n.Ay.RIGHT},te={name:W.UW.Latency,header:W.H6.Latency,width:100,render:({row:e})=>(0,h.f8)(e.LatencyPutTabletLogMs)?(0,k.Xo)(e.LatencyPutTabletLogMs):v.Pd,align:n.Ay.RIGHT},se={name:W.UW.AllocationUnits,header:W.H6.AllocationUnits,width:150,render:({row:e})=>(0,h.f8)(e.AllocationUnits)?(0,f.ZV)(e.AllocationUnits):v.Pd,align:n.Ay.RIGHT},ae=e=>({name:W.UW.VDisks,header:W.H6.VDisks,className:O("vdisks-column"),render:({row:t})=>(0,C.jsx)(z,{vDisks:t.VDisks,viewContext:null===e||void 0===e?void 0:e.viewContext}),align:n.Ay.CENTER,width:780,resizeable:!1,sortable:!1}),ne=e=>({name:W.UW.VDisksPDisks,header:W.H6.VDisksPDisks,className:O("disks-column"),render:({row:t})=>(0,C.jsx)(P,{vDisks:t.VDisks,viewContext:null===e||void 0===e?void 0:e.viewContext}),align:n.Ay.CENTER,width:900,resizeable:!1,sortable:!1}),re=()=>[K,F,_,Y,Q,q].map((e=>({...e,sortable:!1}))),oe=e=>[K,H,F,_,B,$,Y,J,Q,q,X,Z,ee,te,se,ae(e),ne(e)].map((e=>({...e,sortable:(0,W.i4)(e.name)})))},10360:(e,t,s)=>{s.d(t,{hu:()=>u,YX:()=>f,LO:()=>c,UW:()=>d,H6:()=>m,qK:()=>i,SE:()=>g,zY:()=>l,GP:()=>k,i4:()=>N,kY:()=>v});var a=s(370),n=s(48372);const r=JSON.parse('{"pool-name":"Pool Name","type":"Type","encryption":"Encryption","erasure":"Erasure","degraded":"Degraded","missing-disks":"Missing Disks","state":"State","usage":"Usage","disk-usage":"Disk usage","group-id":"Group ID","used":"Used","limit":"Limit","space":"Space","read":"Read","write":"Write","latency":"Latency","allocation-units":"Allocation Units","vdisks":"VDisks","vdisks-pdisks":"VDisks with PDisks"}'),o=(0,n.g4)("ydb-storage-groups-columns",{en:r}),i="storageGroupsColumnsWidth",l="storageGroupsSelectedColumns",d={GroupId:"GroupId",PoolName:"PoolName",MediaType:"MediaType",Erasure:"Erasure",Used:"Used",Limit:"Limit",Usage:"Usage",DiskSpaceUsage:"DiskSpaceUsage",DiskSpace:"DiskSpace",Read:"Read",Write:"Write",Latency:"Latency",AllocationUnits:"AllocationUnits",VDisks:"VDisks",VDisksPDisks:"VDisksPDisks",Degraded:"Degraded",State:"State"},u=["GroupId","PoolName","Erasure","Used","VDisks"],c=["GroupId"],m={get PoolName(){return o("pool-name")},get MediaType(){return o("type")},get Erasure(){return o("erasure")},get GroupId(){return o("group-id")},get Used(){return o("used")},get Limit(){return o("limit")},get Usage(){return o("usage")},get DiskSpaceUsage(){return o("disk-usage")},get DiskSpace(){return o("space")},get Read(){return o("read")},get Write(){return o("write")},get Latency(){return o("latency")},get AllocationUnits(){return o("allocation-units")},get VDisks(){return o("vdisks")},get VDisksPDisks(){return o("vdisks-pdisks")},get Degraded(){return o("missing-disks")},get State(){return o("state")}},p={get GroupId(){return o("group-id")},get Erasure(){return o("erasure")},get Usage(){return o("usage")},get DiskSpaceUsage(){return o("disk-usage")},get PoolName(){return o("pool-name")},get Kind(){return o("type")},get Encryption(){return o("encryption")},get MediaType(){return o("type")},get MissingDisks(){return o("missing-disks")},get State(){return o("state")},get Latency(){return o("latency")}},h=["PoolName","MediaType","Encryption","Erasure","Usage","DiskSpaceUsage","State","MissingDisks","Latency"],g=h.map((e=>({value:e,content:p[e]}))),v=a.z.custom((e=>h.includes(e))).catch(void 0),f={GroupId:["GroupId"],PoolName:["PoolName"],MediaType:["MediaType","Encryption"],Erasure:["Erasure"],Used:["Used"],Limit:["Limit"],Usage:["Usage"],DiskSpaceUsage:["DiskSpaceUsage"],DiskSpace:["State"],Read:["Read"],Write:["Write"],Latency:["Latency"],AllocationUnits:["AllocationUnits"],VDisks:["VDisk","PDisk","Read","Write"],VDisksPDisks:["VDisk","PDisk","Read","Write"],Degraded:["MissingDisks"],State:["State"]},S={GroupId:"GroupId",PoolName:"PoolName",MediaType:"MediaType",Erasure:"Erasure",Used:"Used",Limit:"Limit",Usage:"Usage",DiskSpaceUsage:"DiskSpaceUsage",DiskSpace:void 0,Read:"Read",Write:"Write",Latency:"Latency",AllocationUnits:"AllocationUnits",VDisks:void 0,VDisksPDisks:void 0,Degraded:"Degraded",State:"State"};function k(e){return S[e]}function N(e){return Boolean(k(e))}},61456:(e,t,s)=>{s.d(t,{A:()=>o});var a=s(48372);const n=JSON.parse('{"empty.default":"No such groups","empty.out_of_space":"No groups with out of space errors","empty.degraded":"No degraded groups","show_all":"Show all groups","encrypted":"Encrypted group"}'),r=JSON.parse('{"empty.default":"\u041d\u0435\u0442 \u0433\u0440\u0443\u043f\u043f","empty.out_of_space":"\u041d\u0435\u0442 \u0433\u0440\u0443\u043f\u043f, \u0432 \u043a\u043e\u0442\u043e\u0440\u044b\u0445 \u043a\u043e\u043d\u0447\u0430\u0435\u0442\u0441\u044f \u043c\u0435\u0441\u0442\u043e","empty.degraded":"\u041d\u0435\u0442 \u0434\u0435\u0433\u0440\u0430\u0434\u0438\u0440\u043e\u0432\u0430\u0432\u0448\u0438\u0445 \u0433\u0440\u0443\u043f\u043f","show_all":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435 \u0433\u0440\u0443\u043f\u043f\u044b","encrypted":"\u0417\u0430\u0448\u0438\u0444\u0440\u043e\u0432\u0430\u043d\u043d\u0430\u044f \u0433\u0440\u0443\u043f\u043f\u0430"}'),o=(0,a.g4)("ydb-storage-groups",{ru:r,en:n})},71708:(e,t,s)=>{s.d(t,{Q:()=>d});s(59284);var a=s(33705),n=s(98089),r=s(47665),o=s(77506),i=s(60712);const l=(0,o.cn)("ydb-table-group");function d({children:e,title:t,entityName:s,count:o,expanded:d=!1,onIsExpandedChange:u}){const c=()=>{u(t,!d)};return(0,i.jsxs)("div",{className:l(null),children:[(0,i.jsx)("button",{onClick:c,className:l("button"),title:t,children:(0,i.jsxs)("div",{className:l("title-wrapper"),children:[(0,i.jsx)(a.I,{direction:d?"top":"bottom"}),(0,i.jsxs)("div",{className:l("title"),children:[(0,i.jsx)(n.E,{variant:"subheader-2",children:t}),(0,i.jsxs)(n.E,{variant:"body-2",color:"secondary",className:l("count"),children:[s,": ",(0,i.jsx)(r.J,{theme:"normal",children:o})]})]})]})}),d?(0,i.jsx)("div",{className:l("content"),children:e}):null]})}},62710:(e,t,s)=>{s.d(t,{$:()=>n});var a=s(59284);function n(e){const[t,s]=a.useState({});a.useEffect((()=>{null!==e&&void 0!==e&&e.length&&s((t=>e.reduce(((e,{name:s})=>{const a=t[s];return{...e,[s]:null!==a&&void 0!==a&&a}}),{})))}),[e]);return{expandedGroups:t,setIsGroupExpanded:a.useCallback(((e,t)=>{s((s=>({...s,[e]:t})))}),[])}}},3218:(e,t,s)=>{s.d(t,{Ep:()=>g,OH:()=>c,QQ:()=>h,b0:()=>p,k_:()=>u});var a=s(59284),n=s(24600),r=s(7435),o=s(16439),i=s(90182);const l=(0,o.H)(["success","warning","danger"],1,2),d={"block-4-2":(0,o.H)(["success","warning","danger"],1,2),"mirror-3-dc":(0,o.H)(["success","warning","danger"],1,3)},u=e=>{var t;return(void 0!==(t=e.ErasureSpecies)&&t in d?d[e.ErasureSpecies]:l)(e.Degraded)};function c(e,t){var s;let a=!0;return(0,r.f8)(null===(s=e.VDiskId)||void 0===s?void 0:s.GroupID)&&null!==t&&void 0!==t&&t.groupId&&(a&&=String(e.VDiskId.GroupID)===t.groupId),(0,r.f8)(e.NodeId)&&null!==t&&void 0!==t&&t.nodeId&&(a&&=String(e.NodeId)===t.nodeId),(0,r.f8)(e.PDiskId)&&null!==t&&void 0!==t&&t.pDiskId&&(a&&=String(e.PDiskId)===t.pDiskId),(0,r.f8)(e.VDiskSlotId)&&null!==t&&void 0!==t&&t.vDiskSlotId&&(a&&=String(e.VDiskSlotId)===t.vDiskSlotId),a}const m=10;function p(e){return(0,r.f8)(null===e||void 0===e?void 0:e.nodeId)||(0,r.f8)(null===e||void 0===e?void 0:e.pDiskId)||(0,r.f8)(null===e||void 0===e?void 0:e.vDiskSlotId)?1:m}function h(e){return(0,r.f8)(null===e||void 0===e?void 0:e.groupId)||(0,r.f8)(null===e||void 0===e?void 0:e.vDiskSlotId)?1:m}function g(e=[]){const t=(0,i.N4)(n.K);return a.useMemo((()=>{const s=[];return e.forEach(((a,n)=>{var r,o,i;(null===t||void 0===t||null===(r=t.get(Number(null===a||void 0===a?void 0:a.NodeId)))||void 0===r?void 0:r.DC)!==(null===t||void 0===t||null===(o=t.get(Number(null===(i=e[n+1])||void 0===i?void 0:i.NodeId)))||void 0===o?void 0:o.DC)&&s.push(n)})),s}),[e,t])}},16029:(e,t,s)=>{s.d(t,{t:()=>n});var a=s(11905);async function n({version:e="v2",shouldUseGroupsHandler:t,...s},n){if(t&&"v1"!==e){const e=await window.api.storage.getStorageGroups({...s},n);return(0,a.Rv)(e)}{const t=await window.api.viewer.getStorageInfo({version:e,...s},n);return(0,a.Qi)(t)}}},10174:(e,t,s)=>{s.d(t,{S:()=>o});var a=s(21334),n=s(16029),r=s(11905);const o=a.F.injectEndpoints({endpoints:e=>({getStorageNodesInfo:e.query({queryFn:async(e,{signal:t})=>{try{const s=await window.api.viewer.getNodes({storage:!0,type:"static",...e},{signal:t});return{data:(0,r.rz)(s)}}catch(s){return{error:s}}},providesTags:["All","StorageData"]}),getStorageGroupsInfo:e.query({queryFn:async(e,{signal:t})=>{try{return{data:await(0,n.t)(e,{signal:t})}}catch(s){return{error:s}}},providesTags:["All","StorageData"]})}),overrideExisting:"throw"})},11905:(e,t,s)=>{s.d(t,{Rv:()=>N,rz:()=>S,Qi:()=>k});var a=s(94025),n=s(67375),r=s(7187),o=s(27295),i=s(78034);var l=s(73891),d=s(56839),u=s(51930),c=s(64036),m=s(78461);function p(e={}){var t,s,a,n;const{Whiteboard:i={},PDisk:l,...h}=e,g={...i,...h,VDiskId:i.VDiskId},v=l?function(e={}){var t,s,a;const{Whiteboard:n,...i}=e,l={...n,...i,PDiskId:null===n||void 0===n?void 0:n.PDiskId},d=i.PDiskId||(0,r.r$)(l.NodeId,l.PDiskId),{AllocatedPercent:c,AllocatedSize:p,AvailableSize:h,TotalSize:g}=(0,o.hK)({AvailableSize:l.AvailableSize,TotalSize:l.TotalSize}),v=null!==(t=null===(s=i.Type)||void 0===s?void 0:s.toUpperCase())&&void 0!==t?t:(0,m.Y)(null===n||void 0===n?void 0:n.Category),f=(0,u.d)({State:null===n||void 0===n?void 0:n.State,AllocatedPercent:c}),S=null!==(a=i.SlotSize)&&void 0!==a?a:null===n||void 0===n?void 0:n.EnforcedDynamicSlotSize;return{...l,StringifiedId:d,AllocatedPercent:c,AllocatedSize:p,AvailableSize:h,TotalSize:g,Type:v,Severity:f,SlotSize:S}}({...l,NodeId:g.NodeId}):void 0,f=null!==(t=null===v||void 0===v?void 0:v.PDiskId)&&void 0!==t?t:null===i||void 0===i?void 0:i.PDiskId,S=null!==(s=h.VDiskId)&&void 0!==s?s:(0,d.U9)(i.VDiskId),k=(0,c.b)(g),N=(0,o.LW)({AvailableSize:null!==(a=g.AvailableSize)&&void 0!==a?a:null===l||void 0===l?void 0:l.AvailableSize,AllocatedSize:g.AllocatedSize}),y=null===(n=h.Donors)||void 0===n?void 0:n.map((e=>p({...e,Whiteboard:{...e.Whiteboard,DonorMode:!0}})));return{...g,...N,PDisk:v,Donors:y,PDiskId:f,StringifiedId:S,Severity:k}}function h(e){const{DiskSpace:t,VDisks:s=[]}=e;return t||(0,r.XY)(Math.max(...s.map((e=>(0,r.H7)(e.DiskSpace)))))}const g=(e,t)=>{var s;const a=(0,o.WT)(e);return{...a,StoragePoolName:t,Donors:null===a||void 0===a||null===(s=a.Donors)||void 0===s?void 0:s.map((e=>({...e,StoragePoolName:t})))}},v=(e,t)=>{var s;let r,i=0,l=0,d=0,u=0,c=0;const{Name:m,MediaType:p}=t;if(e.VDisks)for(const h of e.VDisks){const{Replicated:e,VDiskState:t,AvailableSize:s,AllocatedSize:m,PDisk:p,ReadThroughput:g,WriteThroughput:v}=h,{Type:f,State:S,AvailableSize:k}=(0,o.or)(p);e&&S===a.t.Normal&&t===n.W.OK||(i+=1);const N=Number(null!==s&&void 0!==s?s:k)||0,y=Number(m)||0;l+=y,d+=N+y,u+=Number(g)||0,c+=Number(v)||0,r=!f||f!==r&&r?"Mixed":f}const v=null===(s=e.VDisks)||void 0===s?void 0:s.map((e=>g(e,m))),f=d?((e,t=1)=>{const s=e.Limit?100*e.Used/e.Limit:0;return Math.floor(s/t)*t})({Used:l,Limit:d},5):void 0,S=h(e);return{...e,GroupGeneration:e.GroupGeneration?String(e.GroupGeneration):void 0,GroupId:e.GroupID,Overall:e.Overall,VDisks:v,Usage:f,Read:u,Write:c,PoolName:m,Used:l,Limit:d,Degraded:i,MediaType:p||r||void 0,DiskSpace:S}},f=e=>{const{VDisks:t=[],PoolName:s,Usage:a=0,Read:n=0,Write:r=0,Used:o=0,Limit:i=0,Degraded:l=0,Kind:d,MediaType:u,GroupID:c,Overall:m,GroupGeneration:p}=e,v=t.map((e=>g(e,s))),f=100*Number(a),S=h(e);return{...e,PoolName:s,GroupId:c,MediaType:u||d,VDisks:v,Usage:f,Overall:m,GroupGeneration:p?String(p):void 0,Read:Number(n),Write:Number(r),Used:Number(o),Limit:Number(i),Degraded:Number(l),DiskSpace:S}},S=e=>{const{Nodes:t,TotalNodes:s,FoundNodes:n,NodeGroups:r,MaximumSlotsPerDisk:l,MaximumDisksPerNode:d}=e,u=null===r||void 0===r?void 0:r.map((({GroupName:e,NodeCount:t})=>{if(e&&t)return{name:e,count:Number(t)}})).filter((e=>Boolean(e))),c=((e,t)=>{if(t)return t;const s=(e||[]).flatMap((e=>{const t=e.PDisks||[],s=e.VDisks||[];return t.map((e=>s.filter((t=>t.PDiskId===e.PDiskId)).length||0))})),a=Math.max(1,...s);return String(a)})(t,l),m=((e,t)=>{if(t)return t;const s=(e||[]).map((e=>{var t;return(null===(t=e.PDisks)||void 0===t?void 0:t.length)||0})),a=Math.max(1,...s);return String(a)})(t,d),p=null===t||void 0===t?void 0:t.map((e=>((e,t,s)=>{var n,r,l;const d=(null===(n=e.PDisks)||void 0===n?void 0:n.filter((e=>e.State!==a.t.Normal)).length)||0,u=null===(r=e.PDisks)||void 0===r?void 0:r.map((t=>({...(0,o.or)(t),NodeId:e.NodeId}))),c=null===(l=e.VDisks)||void 0===l?void 0:l.map((t=>({...(0,o.WT)(t),NodeId:e.NodeId})));return{...(0,i.q1)(e.SystemState),NodeId:e.NodeId,DiskSpaceUsage:e.DiskSpaceUsage,PDisks:u,VDisks:c,Missing:d,MaximumSlotsPerDisk:t,MaximumDisksPerNode:s}})(e,c,m)));return{nodes:p,total:Number(s)||(null===p||void 0===p?void 0:p.length),found:Number(n),tableGroups:u}},k=e=>{const{StoragePools:t,StorageGroups:s,TotalGroups:a,FoundGroups:n}=e,r=((e,t)=>{let s=[];return e?s=e.map(f):null===t||void 0===t||t.forEach((e=>{var t;null===(t=e.Groups)||void 0===t||t.forEach((t=>{s.push(v(t,e))}))})),s})(s,t);return{groups:r,total:Number(a)||r.length,found:Number(n)}};function N(e){const{FoundGroups:t,TotalGroups:s,StorageGroups:a=[],StorageGroupGroups:n}=e,r=a.map((e=>{const{Usage:t,DiskSpaceUsage:s,Read:a,Write:n,Used:r,Limit:o,MissingDisks:i,VDisks:d=[],Overall:u,LatencyPutTabletLog:c,LatencyPutUserData:m,LatencyGetFast:g}=e,v=d.map(p),f=h(e);return{...e,Usage:t,DiskSpaceUsage:s,Read:Number(a),Write:Number(n),Used:Number(r),Limit:Number(o),LatencyPutTabletLogMs:(0,l.Jc)(c),LatencyPutUserDataMs:(0,l.Jc)(m),LatencyGetFastMs:(0,l.Jc)(g),Degraded:Number(i),Overall:u,VDisks:v,DiskSpace:f}})),o=null===n||void 0===n?void 0:n.map((({GroupName:e,GroupCount:t})=>{if(e&&t)return{name:e,count:Number(t)}})).filter((e=>Boolean(e)));return{groups:r,total:Number(s)||r.length,found:Number(t),tableGroups:o}}},94025:(e,t,s)=>{s.d(t,{t:()=>a});let a=function(e){return e.Initial="Initial",e.InitialFormatRead="InitialFormatRead",e.InitialFormatReadError="InitialFormatReadError",e.InitialSysLogRead="InitialSysLogRead",e.InitialSysLogReadError="InitialSysLogReadError",e.InitialSysLogParseError="InitialSysLogParseError",e.InitialCommonLogRead="InitialCommonLogRead",e.InitialCommonLogReadError="InitialCommonLogReadError",e.InitialCommonLogParseError="InitialCommonLogParseError",e.CommonLoggerInitError="CommonLoggerInitError",e.Normal="Normal",e.OpenFileError="OpenFileError",e.ChunkQuotaError="ChunkQuotaError",e.DeviceIoError="DeviceIoError",e.Missing="Missing",e.Timeout="Timeout",e.NodeDisconnected="NodeDisconnected",e.Unknown="Unknown",e}({})},67375:(e,t,s)=>{s.d(t,{W:()=>a});let a=function(e){return e.Initial="Initial",e.LocalRecoveryError="LocalRecoveryError",e.SyncGuidRecovery="SyncGuidRecovery",e.SyncGuidRecoveryError="SyncGuidRecoveryError",e.OK="OK",e.PDiskError="PDiskError",e}({})},51930:(e,t,s)=>{s.d(t,{d:()=>i});var a=s(54090),n=s(16439),r=s(5707);const o=(0,n.H)([a.m.Green,a.m.Yellow,a.m.Red]);function i(e){const t=function(e){return t=e,void 0!==t&&t in r.iZ?r.iZ[e]:r.Km;var t}(e.State),s=o(e.AllocatedPercent||0);return t!==r.Km&&s?Math.max(t,r.aW[s]):t}},64036:(e,t,s)=>{s.d(t,{b:()=>n});var a=s(5707);function n(e){const{DiskSpace:t,VDiskState:s,FrontQueues:n,Replicated:o}=e;if(!s)return a.Km;const i=r(t),l=function(e){var t;if(!e)return a.Km;return null!==(t=a.qs[e])&&void 0!==t?t:a.Km}(s),d=Math.min(a.aW.Orange,r(n));let u=Math.max(i,l,d);return o||u!==a.aW.Green||(u=a.aW.Blue),u}function r(e){var t;return e&&null!==(t=a.aW[e])&&void 0!==t?t:a.Km}},5707:(e,t,s)=>{s.d(t,{A$:()=>o,Km:()=>i,Yh:()=>l,aW:()=>r,iZ:()=>u,qs:()=>d});var a=s(94025),n=s(67375);const r={Grey:0,Green:1,Blue:2,Yellow:3,Orange:4,Red:5},o=Object.entries(r).reduce(((e,[t,s])=>({...e,[s]:t})),{}),i=r.Grey,l=o[i],d={[n.W.OK]:r.Green,[n.W.Initial]:r.Yellow,[n.W.SyncGuidRecovery]:r.Yellow,[n.W.LocalRecoveryError]:r.Red,[n.W.SyncGuidRecoveryError]:r.Red,[n.W.PDiskError]:r.Red},u={[a.t.Initial]:r.Grey,[a.t.Normal]:r.Green,[a.t.InitialFormatRead]:r.Yellow,[a.t.InitialSysLogRead]:r.Yellow,[a.t.InitialCommonLogRead]:r.Yellow,[a.t.InitialFormatReadError]:r.Red,[a.t.InitialSysLogReadError]:r.Red,[a.t.InitialSysLogParseError]:r.Red,[a.t.InitialCommonLogReadError]:r.Red,[a.t.InitialCommonLogParseError]:r.Red,[a.t.CommonLoggerInitError]:r.Red,[a.t.OpenFileError]:r.Red,[a.t.ChunkQuotaError]:r.Red,[a.t.DeviceIoError]:r.Red}},78461:(e,t,s)=>{s.d(t,{Y:()=>n});const a={HDD:"HDD",SSD:"SSD",MVME:"NVME"};function n(e){if(!e)return;const t=function(e,t){const s={};return Object.entries(t).reduce(((t,[a,n])=>{const r=e.length-t,o=r-n;return s[a]=e.substring(o,r)||"0",t+n}),0),s}(BigInt(e).toString(2),{isSolidState:1,kind:55,typeExt:8});if("1"===t.isSolidState)switch(parseInt(t.typeExt,2)){case 0:return a.SSD;case 2:return a.MVME}else if("0"===t.typeExt)return a.HDD}},7187:(e,t,s)=>{s.d(t,{H7:()=>i,NJ:()=>r,XY:()=>o,gh:()=>d,r$:()=>l});var a=s(7435),n=s(5707);function r(e){return"VDiskId"in e}function o(e){return void 0===e?n.Yh:n.A$[e]||n.Yh}function i(e){return e?n.aW[e]:0}function l(e,t){if((0,a.f8)(e)&&(0,a.f8)(t))return`${e}-${t}`}function d(e,t,s){return[e,t,s].join("-")}},27295:(e,t,s)=>{s.d(t,{LW:()=>u,WT:()=>l,hK:()=>c,or:()=>d});var a=s(56839),n=s(51930),r=s(64036),o=s(78461),i=s(7187);function l(e={}){var t;if(!(0,i.NJ)(e)){const{NodeId:t,PDiskId:s,VSlotId:n}=e;return{StringifiedId:(0,a.U9)({NodeId:t,PDiskId:s,VSlotId:n}),NodeId:t,PDiskId:s,VDiskSlotId:n}}const{PDisk:s,PDiskId:n,VDiskId:o,NodeId:c,Donors:m,AvailableSize:p,AllocatedSize:h,...g}=e,v=s?d({...s,NodeId:null!==(t=null===s||void 0===s?void 0:s.NodeId)&&void 0!==t?t:c}):void 0,f=null!==n&&void 0!==n?n:null===v||void 0===v?void 0:v.PDiskId,S=u({AvailableSize:null!==p&&void 0!==p?p:null===s||void 0===s?void 0:s.AvailableSize,AllocatedSize:h}),k=(0,r.b)(e),N=(0,a.U9)(o);return{...g,...S,VDiskId:o,NodeId:c,PDiskId:f,PDisk:v,Donors:null===m||void 0===m?void 0:m.map((e=>l({...e,DonorMode:!0}))),Severity:k,StringifiedId:N}}function d(e={}){const{AvailableSize:t,TotalSize:s,Category:a,State:r,PDiskId:l,NodeId:d,EnforcedDynamicSlotSize:u,...m}=e,p=(0,i.r$)(l,d),h=(0,o.Y)(a),g=c({AvailableSize:t,TotalSize:s}),v=(0,n.d)({State:r,AllocatedPercent:g.AllocatedPercent});return{...m,...g,PDiskId:l,NodeId:d,StringifiedId:p,Type:h,Category:a,State:r,Severity:v,SlotSize:u}}function u({AvailableSize:e,AllocatedSize:t}){const s=Number(e),a=Number(t),n=a+s;return{AvailableSize:s,AllocatedSize:a,TotalSize:n,AllocatedPercent:Math.round(100*a/n)}}function c({AvailableSize:e,TotalSize:t}){const s=Number(e),a=Number(t),n=a-s;return{AvailableSize:s,TotalSize:a,AllocatedSize:n,AllocatedPercent:Math.round(100*n/a)}}},69464:(e,t,s)=>{s.d(t,{T:()=>n});var a=s(6388);s(23536);const n=(e,t=a.xN)=>t===a.xN?`-${e}`:e},16439:(e,t,s)=>{s.d(t,{H:()=>n,f:()=>r});var a=s(76086);const n=(e,t=a.Hh,s=a.Ed)=>a=>0<=a&&a{s.d(t,{K:()=>r});var a=s(59284),n=s(59001);const r=(e,t,s,r,o)=>{const[i,l]=a.useState((()=>n.f.readUserSettingsValue(t,r)));return{columnsToShow:a.useMemo((()=>e.filter((e=>{const t=e.name,s=i.includes(t),a=null===o||void 0===o?void 0:o.includes(t);return s||a}))),[e,o,i]),columnsToSelect:a.useMemo((()=>e.map((e=>e.name)).map((e=>{const t=null===o||void 0===o?void 0:o.includes(e),a=i.includes(e);return{id:e,title:s[e],selected:t||a,required:t,sticky:t?"start":void 0}}))),[e,s,o,i]),setColumns:a.useCallback((e=>{const s=e.filter((e=>e.selected)).map((e=>e.id));n.f.setUserSettingsValue(t,s),l(s)}),[t])}}},16819:(e,t,s)=>{s.d(t,{a:()=>o});var a=s(59284),n=s(69024),r=s(59001);const o=e=>{const t=a.useCallback((()=>e?r.f.readUserSettingsValue(e,{}):{}),[e]),s=a.useCallback((t=>{e&&r.f.setUserSettingsValue(e,t)}),[e]);return(0,n.a)({saveSizes:s,getSizes:t})}},35736:(e,t,s)=>{s.d(t,{w:()=>n});var a=s(76086);function n({inverseColorize:e,warningThreshold:t=a.Hh,dangerThreshold:s=a.Ed,colorizeProgress:n,fillWidth:r}){let o=e?"danger":"good";return n&&(r>t&&r<=s?o="warning":r>s&&(o=e?"good":"danger")),o}},40781:(e,t,s)=>{function a(e,t){const s=e.reduce(((e,s)=>(t[s].forEach((t=>{e.add(t)})),e)),new Set);return Array.from(s).sort()}s.d(t,{R:()=>a})},58267:(e,t,s)=>{s.d(t,{P:()=>o,_:()=>i});var a=s(54090),n=s(6354);const r={[n.r.Dead]:a.m.Red,[n.r.Created]:a.m.Yellow,[n.r.ResolveStateStorage]:a.m.Yellow,[n.r.Candidate]:a.m.Yellow,[n.r.BlockBlobStorage]:a.m.Yellow,[n.r.WriteZeroEntry]:a.m.Yellow,[n.r.Restored]:a.m.Yellow,[n.r.Discover]:a.m.Yellow,[n.r.Lock]:a.m.Yellow,[n.r.Stopped]:a.m.Yellow,[n.r.ResolveLeader]:a.m.Yellow,[n.r.RebuildGraph]:a.m.Yellow,[n.r.Deleted]:a.m.Green,[n.r.Active]:a.m.Green},o=e=>{if(!e)return a.m.Grey;return t=e,Object.values(a.m).includes(t)?e:r[e];var t};function i(e){if(!e)return"unknown";switch(e){case n.r.Dead:return"danger";case n.r.Active:case n.r.Deleted:return"success";default:return"warning"}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9801.b9143d43.chunk.js b/ydb/core/viewer/monitoring/static/js/9801.b9143d43.chunk.js deleted file mode 100644 index 65fce1dd2bdb..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9801.b9143d43.chunk.js +++ /dev/null @@ -1 +0,0 @@ -(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9801],{52182:function(e,n,t){e.exports=function(e){"use strict";function n(e){return e&&"object"==typeof e&&"default"in e?e:{default:e}}var t=n(e);function r(e){return e%100==2}function a(e){return e%100==3||e%100==4}function m(e,n,t,m){var u=e+" ";switch(t){case"s":return n||m?"nekaj sekund":"nekaj sekundami";case"m":return n?"ena minuta":"eno minuto";case"mm":return r(e)?u+(n||m?"minuti":"minutama"):a(e)?u+(n||m?"minute":"minutami"):u+(n||m?"minut":"minutami");case"h":return n?"ena ura":"eno uro";case"hh":return r(e)?u+(n||m?"uri":"urama"):a(e)?u+(n||m?"ure":"urami"):u+(n||m?"ur":"urami");case"d":return n||m?"en dan":"enim dnem";case"dd":return r(e)?u+(n||m?"dneva":"dnevoma"):u+(n||m?"dni":"dnevi");case"M":return n||m?"en mesec":"enim mesecem";case"MM":return r(e)?u+(n||m?"meseca":"mesecema"):a(e)?u+(n||m?"mesece":"meseci"):u+(n||m?"mesecev":"meseci");case"y":return n||m?"eno leto":"enim letom";case"yy":return r(e)?u+(n||m?"leti":"letoma"):a(e)?u+(n||m?"leta":"leti"):u+(n||m?"let":"leti")}}var u={name:"sl",weekdays:"nedelja_ponedeljek_torek_sreda_\u010detrtek_petek_sobota".split("_"),months:"januar_februar_marec_april_maj_junij_julij_avgust_september_oktober_november_december".split("_"),weekStart:1,weekdaysShort:"ned._pon._tor._sre._\u010det._pet._sob.".split("_"),monthsShort:"jan._feb._mar._apr._maj._jun._jul._avg._sep._okt._nov._dec.".split("_"),weekdaysMin:"ne_po_to_sr_\u010de_pe_so".split("_"),ordinal:function(e){return e+"."},formats:{LT:"H:mm",LTS:"H:mm:ss",L:"DD.MM.YYYY",LL:"D. MMMM YYYY",LLL:"D. MMMM YYYY H:mm",LLLL:"dddd, D. MMMM YYYY H:mm",l:"D. M. YYYY"},relativeTime:{future:"\u010dez %s",past:"pred %s",s:m,m:m,mm:m,h:m,hh:m,d:m,dd:m,M:m,MM:m,y:m,yy:m}};return t.default.locale(u,null,!0),u}(t(88409))}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/98014.a4ad6ba5.chunk.js b/ydb/core/viewer/monitoring/static/js/98014.a4ad6ba5.chunk.js new file mode 100644 index 000000000000..5de6aaa92f22 --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/98014.a4ad6ba5.chunk.js @@ -0,0 +1,2 @@ +/*! For license information please see 98014.a4ad6ba5.chunk.js.LICENSE.txt */ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[98014],{98014:(e,n,t)=>{t.r(n),t.d(n,{conf:()=>r,language:()=>i});var o=`\\b${"[_a-zA-Z][_a-zA-Z0-9]*"}\\b`,r={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"'",close:"'"},{open:"'''",close:"'''"}],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"'",close:"'",notIn:["string","comment"]},{open:"'''",close:"'''",notIn:["string","comment"]}],autoCloseBefore:":.,=}])' \n\t",indentationRules:{increaseIndentPattern:new RegExp("^((?!\\/\\/).)*(\\{[^}\"'`]*|\\([^)\"'`]*|\\[[^\\]\"'`]*)$"),decreaseIndentPattern:new RegExp("^((?!.*?\\/\\*).*\\*/)?\\s*[\\}\\]].*$")}},i={defaultToken:"",tokenPostfix:".bicep",brackets:[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"}],symbols:/[=>{i.r(e),i.d(e,{conf:()=>d,language:()=>f});var d={comments:{lineComment:"//",blockComment:["/*","*/"]},brackets:[["{","}"],["[","]"],["(",")"],["<",">"]],autoClosingPairs:[{open:'"',close:'"',notIn:["string","comment"]},{open:"{",close:"}",notIn:["string","comment"]},{open:"[",close:"]",notIn:["string","comment"]},{open:"(",close:")",notIn:["string","comment"]}]},f={defaultToken:"",tokenPostfix:".sol",brackets:[{token:"delimiter.curly",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"},{token:"delimiter.angle",open:"<",close:">"}],keywords:["pragma","solidity","contract","library","using","struct","function","modifier","constructor","address","string","bool","Int","Uint","Byte","Fixed","Ufixed","int","int8","int16","int24","int32","int40","int48","int56","int64","int72","int80","int88","int96","int104","int112","int120","int128","int136","int144","int152","int160","int168","int176","int184","int192","int200","int208","int216","int224","int232","int240","int248","int256","uint","uint8","uint16","uint24","uint32","uint40","uint48","uint56","uint64","uint72","uint80","uint88","uint96","uint104","uint112","uint120","uint128","uint136","uint144","uint152","uint160","uint168","uint176","uint184","uint192","uint200","uint208","uint216","uint224","uint232","uint240","uint248","uint256","byte","bytes","bytes1","bytes2","bytes3","bytes4","bytes5","bytes6","bytes7","bytes8","bytes9","bytes10","bytes11","bytes12","bytes13","bytes14","bytes15","bytes16","bytes17","bytes18","bytes19","bytes20","bytes21","bytes22","bytes23","bytes24","bytes25","bytes26","bytes27","bytes28","bytes29","bytes30","bytes31","bytes32","fixed","fixed0x8","fixed0x16","fixed0x24","fixed0x32","fixed0x40","fixed0x48","fixed0x56","fixed0x64","fixed0x72","fixed0x80","fixed0x88","fixed0x96","fixed0x104","fixed0x112","fixed0x120","fixed0x128","fixed0x136","fixed0x144","fixed0x152","fixed0x160","fixed0x168","fixed0x176","fixed0x184","fixed0x192","fixed0x200","fixed0x208","fixed0x216","fixed0x224","fixed0x232","fixed0x240","fixed0x248","fixed0x256","fixed8x8","fixed8x16","fixed8x24","fixed8x32","fixed8x40","fixed8x48","fixed8x56","fixed8x64","fixed8x72","fixed8x80","fixed8x88","fixed8x96","fixed8x104","fixed8x112","fixed8x120","fixed8x128","fixed8x136","fixed8x144","fixed8x152","fixed8x160","fixed8x168","fixed8x176","fixed8x184","fixed8x192","fixed8x200","fixed8x208","fixed8x216","fixed8x224","fixed8x232","fixed8x240","fixed8x248","fixed16x8","fixed16x16","fixed16x24","fixed16x32","fixed16x40","fixed16x48","fixed16x56","fixed16x64","fixed16x72","fixed16x80","fixed16x88","fixed16x96","fixed16x104","fixed16x112","fixed16x120","fixed16x128","fixed16x136","fixed16x144","fixed16x152","fixed16x160","fixed16x168","fixed16x176","fixed16x184","fixed16x192","fixed16x200","fixed16x208","fixed16x216","fixed16x224","fixed16x232","fixed16x240","fixed24x8","fixed24x16","fixed24x24","fixed24x32","fixed24x40","fixed24x48","fixed24x56","fixed24x64","fixed24x72","fixed24x80","fixed24x88","fixed24x96","fixed24x104","fixed24x112","fixed24x120","fixed24x128","fixed24x136","fixed24x144","fixed24x152","fixed24x160","fixed24x168","fixed24x176","fixed24x184","fixed24x192","fixed24x200","fixed24x208","fixed24x216","fixed24x224","fixed24x232","fixed32x8","fixed32x16","fixed32x24","fixed32x32","fixed32x40","fixed32x48","fixed32x56","fixed32x64","fixed32x72","fixed32x80","fixed32x88","fixed32x96","fixed32x104","fixed32x112","fixed32x120","fixed32x128","fixed32x136","fixed32x144","fixed32x152","fixed32x160","fixed32x168","fixed32x176","fixed32x184","fixed32x192","fixed32x200","fixed32x208","fixed32x216","fixed32x224","fixed40x8","fixed40x16","fixed40x24","fixed40x32","fixed40x40","fixed40x48","fixed40x56","fixed40x64","fixed40x72","fixed40x80","fixed40x88","fixed40x96","fixed40x104","fixed40x112","fixed40x120","fixed40x128","fixed40x136","fixed40x144","fixed40x152","fixed40x160","fixed40x168","fixed40x176","fixed40x184","fixed40x192","fixed40x200","fixed40x208","fixed40x216","fixed48x8","fixed48x16","fixed48x24","fixed48x32","fixed48x40","fixed48x48","fixed48x56","fixed48x64","fixed48x72","fixed48x80","fixed48x88","fixed48x96","fixed48x104","fixed48x112","fixed48x120","fixed48x128","fixed48x136","fixed48x144","fixed48x152","fixed48x160","fixed48x168","fixed48x176","fixed48x184","fixed48x192","fixed48x200","fixed48x208","fixed56x8","fixed56x16","fixed56x24","fixed56x32","fixed56x40","fixed56x48","fixed56x56","fixed56x64","fixed56x72","fixed56x80","fixed56x88","fixed56x96","fixed56x104","fixed56x112","fixed56x120","fixed56x128","fixed56x136","fixed56x144","fixed56x152","fixed56x160","fixed56x168","fixed56x176","fixed56x184","fixed56x192","fixed56x200","fixed64x8","fixed64x16","fixed64x24","fixed64x32","fixed64x40","fixed64x48","fixed64x56","fixed64x64","fixed64x72","fixed64x80","fixed64x88","fixed64x96","fixed64x104","fixed64x112","fixed64x120","fixed64x128","fixed64x136","fixed64x144","fixed64x152","fixed64x160","fixed64x168","fixed64x176","fixed64x184","fixed64x192","fixed72x8","fixed72x16","fixed72x24","fixed72x32","fixed72x40","fixed72x48","fixed72x56","fixed72x64","fixed72x72","fixed72x80","fixed72x88","fixed72x96","fixed72x104","fixed72x112","fixed72x120","fixed72x128","fixed72x136","fixed72x144","fixed72x152","fixed72x160","fixed72x168","fixed72x176","fixed72x184","fixed80x8","fixed80x16","fixed80x24","fixed80x32","fixed80x40","fixed80x48","fixed80x56","fixed80x64","fixed80x72","fixed80x80","fixed80x88","fixed80x96","fixed80x104","fixed80x112","fixed80x120","fixed80x128","fixed80x136","fixed80x144","fixed80x152","fixed80x160","fixed80x168","fixed80x176","fixed88x8","fixed88x16","fixed88x24","fixed88x32","fixed88x40","fixed88x48","fixed88x56","fixed88x64","fixed88x72","fixed88x80","fixed88x88","fixed88x96","fixed88x104","fixed88x112","fixed88x120","fixed88x128","fixed88x136","fixed88x144","fixed88x152","fixed88x160","fixed88x168","fixed96x8","fixed96x16","fixed96x24","fixed96x32","fixed96x40","fixed96x48","fixed96x56","fixed96x64","fixed96x72","fixed96x80","fixed96x88","fixed96x96","fixed96x104","fixed96x112","fixed96x120","fixed96x128","fixed96x136","fixed96x144","fixed96x152","fixed96x160","fixed104x8","fixed104x16","fixed104x24","fixed104x32","fixed104x40","fixed104x48","fixed104x56","fixed104x64","fixed104x72","fixed104x80","fixed104x88","fixed104x96","fixed104x104","fixed104x112","fixed104x120","fixed104x128","fixed104x136","fixed104x144","fixed104x152","fixed112x8","fixed112x16","fixed112x24","fixed112x32","fixed112x40","fixed112x48","fixed112x56","fixed112x64","fixed112x72","fixed112x80","fixed112x88","fixed112x96","fixed112x104","fixed112x112","fixed112x120","fixed112x128","fixed112x136","fixed112x144","fixed120x8","fixed120x16","fixed120x24","fixed120x32","fixed120x40","fixed120x48","fixed120x56","fixed120x64","fixed120x72","fixed120x80","fixed120x88","fixed120x96","fixed120x104","fixed120x112","fixed120x120","fixed120x128","fixed120x136","fixed128x8","fixed128x16","fixed128x24","fixed128x32","fixed128x40","fixed128x48","fixed128x56","fixed128x64","fixed128x72","fixed128x80","fixed128x88","fixed128x96","fixed128x104","fixed128x112","fixed128x120","fixed128x128","fixed136x8","fixed136x16","fixed136x24","fixed136x32","fixed136x40","fixed136x48","fixed136x56","fixed136x64","fixed136x72","fixed136x80","fixed136x88","fixed136x96","fixed136x104","fixed136x112","fixed136x120","fixed144x8","fixed144x16","fixed144x24","fixed144x32","fixed144x40","fixed144x48","fixed144x56","fixed144x64","fixed144x72","fixed144x80","fixed144x88","fixed144x96","fixed144x104","fixed144x112","fixed152x8","fixed152x16","fixed152x24","fixed152x32","fixed152x40","fixed152x48","fixed152x56","fixed152x64","fixed152x72","fixed152x80","fixed152x88","fixed152x96","fixed152x104","fixed160x8","fixed160x16","fixed160x24","fixed160x32","fixed160x40","fixed160x48","fixed160x56","fixed160x64","fixed160x72","fixed160x80","fixed160x88","fixed160x96","fixed168x8","fixed168x16","fixed168x24","fixed168x32","fixed168x40","fixed168x48","fixed168x56","fixed168x64","fixed168x72","fixed168x80","fixed168x88","fixed176x8","fixed176x16","fixed176x24","fixed176x32","fixed176x40","fixed176x48","fixed176x56","fixed176x64","fixed176x72","fixed176x80","fixed184x8","fixed184x16","fixed184x24","fixed184x32","fixed184x40","fixed184x48","fixed184x56","fixed184x64","fixed184x72","fixed192x8","fixed192x16","fixed192x24","fixed192x32","fixed192x40","fixed192x48","fixed192x56","fixed192x64","fixed200x8","fixed200x16","fixed200x24","fixed200x32","fixed200x40","fixed200x48","fixed200x56","fixed208x8","fixed208x16","fixed208x24","fixed208x32","fixed208x40","fixed208x48","fixed216x8","fixed216x16","fixed216x24","fixed216x32","fixed216x40","fixed224x8","fixed224x16","fixed224x24","fixed224x32","fixed232x8","fixed232x16","fixed232x24","fixed240x8","fixed240x16","fixed248x8","ufixed","ufixed0x8","ufixed0x16","ufixed0x24","ufixed0x32","ufixed0x40","ufixed0x48","ufixed0x56","ufixed0x64","ufixed0x72","ufixed0x80","ufixed0x88","ufixed0x96","ufixed0x104","ufixed0x112","ufixed0x120","ufixed0x128","ufixed0x136","ufixed0x144","ufixed0x152","ufixed0x160","ufixed0x168","ufixed0x176","ufixed0x184","ufixed0x192","ufixed0x200","ufixed0x208","ufixed0x216","ufixed0x224","ufixed0x232","ufixed0x240","ufixed0x248","ufixed0x256","ufixed8x8","ufixed8x16","ufixed8x24","ufixed8x32","ufixed8x40","ufixed8x48","ufixed8x56","ufixed8x64","ufixed8x72","ufixed8x80","ufixed8x88","ufixed8x96","ufixed8x104","ufixed8x112","ufixed8x120","ufixed8x128","ufixed8x136","ufixed8x144","ufixed8x152","ufixed8x160","ufixed8x168","ufixed8x176","ufixed8x184","ufixed8x192","ufixed8x200","ufixed8x208","ufixed8x216","ufixed8x224","ufixed8x232","ufixed8x240","ufixed8x248","ufixed16x8","ufixed16x16","ufixed16x24","ufixed16x32","ufixed16x40","ufixed16x48","ufixed16x56","ufixed16x64","ufixed16x72","ufixed16x80","ufixed16x88","ufixed16x96","ufixed16x104","ufixed16x112","ufixed16x120","ufixed16x128","ufixed16x136","ufixed16x144","ufixed16x152","ufixed16x160","ufixed16x168","ufixed16x176","ufixed16x184","ufixed16x192","ufixed16x200","ufixed16x208","ufixed16x216","ufixed16x224","ufixed16x232","ufixed16x240","ufixed24x8","ufixed24x16","ufixed24x24","ufixed24x32","ufixed24x40","ufixed24x48","ufixed24x56","ufixed24x64","ufixed24x72","ufixed24x80","ufixed24x88","ufixed24x96","ufixed24x104","ufixed24x112","ufixed24x120","ufixed24x128","ufixed24x136","ufixed24x144","ufixed24x152","ufixed24x160","ufixed24x168","ufixed24x176","ufixed24x184","ufixed24x192","ufixed24x200","ufixed24x208","ufixed24x216","ufixed24x224","ufixed24x232","ufixed32x8","ufixed32x16","ufixed32x24","ufixed32x32","ufixed32x40","ufixed32x48","ufixed32x56","ufixed32x64","ufixed32x72","ufixed32x80","ufixed32x88","ufixed32x96","ufixed32x104","ufixed32x112","ufixed32x120","ufixed32x128","ufixed32x136","ufixed32x144","ufixed32x152","ufixed32x160","ufixed32x168","ufixed32x176","ufixed32x184","ufixed32x192","ufixed32x200","ufixed32x208","ufixed32x216","ufixed32x224","ufixed40x8","ufixed40x16","ufixed40x24","ufixed40x32","ufixed40x40","ufixed40x48","ufixed40x56","ufixed40x64","ufixed40x72","ufixed40x80","ufixed40x88","ufixed40x96","ufixed40x104","ufixed40x112","ufixed40x120","ufixed40x128","ufixed40x136","ufixed40x144","ufixed40x152","ufixed40x160","ufixed40x168","ufixed40x176","ufixed40x184","ufixed40x192","ufixed40x200","ufixed40x208","ufixed40x216","ufixed48x8","ufixed48x16","ufixed48x24","ufixed48x32","ufixed48x40","ufixed48x48","ufixed48x56","ufixed48x64","ufixed48x72","ufixed48x80","ufixed48x88","ufixed48x96","ufixed48x104","ufixed48x112","ufixed48x120","ufixed48x128","ufixed48x136","ufixed48x144","ufixed48x152","ufixed48x160","ufixed48x168","ufixed48x176","ufixed48x184","ufixed48x192","ufixed48x200","ufixed48x208","ufixed56x8","ufixed56x16","ufixed56x24","ufixed56x32","ufixed56x40","ufixed56x48","ufixed56x56","ufixed56x64","ufixed56x72","ufixed56x80","ufixed56x88","ufixed56x96","ufixed56x104","ufixed56x112","ufixed56x120","ufixed56x128","ufixed56x136","ufixed56x144","ufixed56x152","ufixed56x160","ufixed56x168","ufixed56x176","ufixed56x184","ufixed56x192","ufixed56x200","ufixed64x8","ufixed64x16","ufixed64x24","ufixed64x32","ufixed64x40","ufixed64x48","ufixed64x56","ufixed64x64","ufixed64x72","ufixed64x80","ufixed64x88","ufixed64x96","ufixed64x104","ufixed64x112","ufixed64x120","ufixed64x128","ufixed64x136","ufixed64x144","ufixed64x152","ufixed64x160","ufixed64x168","ufixed64x176","ufixed64x184","ufixed64x192","ufixed72x8","ufixed72x16","ufixed72x24","ufixed72x32","ufixed72x40","ufixed72x48","ufixed72x56","ufixed72x64","ufixed72x72","ufixed72x80","ufixed72x88","ufixed72x96","ufixed72x104","ufixed72x112","ufixed72x120","ufixed72x128","ufixed72x136","ufixed72x144","ufixed72x152","ufixed72x160","ufixed72x168","ufixed72x176","ufixed72x184","ufixed80x8","ufixed80x16","ufixed80x24","ufixed80x32","ufixed80x40","ufixed80x48","ufixed80x56","ufixed80x64","ufixed80x72","ufixed80x80","ufixed80x88","ufixed80x96","ufixed80x104","ufixed80x112","ufixed80x120","ufixed80x128","ufixed80x136","ufixed80x144","ufixed80x152","ufixed80x160","ufixed80x168","ufixed80x176","ufixed88x8","ufixed88x16","ufixed88x24","ufixed88x32","ufixed88x40","ufixed88x48","ufixed88x56","ufixed88x64","ufixed88x72","ufixed88x80","ufixed88x88","ufixed88x96","ufixed88x104","ufixed88x112","ufixed88x120","ufixed88x128","ufixed88x136","ufixed88x144","ufixed88x152","ufixed88x160","ufixed88x168","ufixed96x8","ufixed96x16","ufixed96x24","ufixed96x32","ufixed96x40","ufixed96x48","ufixed96x56","ufixed96x64","ufixed96x72","ufixed96x80","ufixed96x88","ufixed96x96","ufixed96x104","ufixed96x112","ufixed96x120","ufixed96x128","ufixed96x136","ufixed96x144","ufixed96x152","ufixed96x160","ufixed104x8","ufixed104x16","ufixed104x24","ufixed104x32","ufixed104x40","ufixed104x48","ufixed104x56","ufixed104x64","ufixed104x72","ufixed104x80","ufixed104x88","ufixed104x96","ufixed104x104","ufixed104x112","ufixed104x120","ufixed104x128","ufixed104x136","ufixed104x144","ufixed104x152","ufixed112x8","ufixed112x16","ufixed112x24","ufixed112x32","ufixed112x40","ufixed112x48","ufixed112x56","ufixed112x64","ufixed112x72","ufixed112x80","ufixed112x88","ufixed112x96","ufixed112x104","ufixed112x112","ufixed112x120","ufixed112x128","ufixed112x136","ufixed112x144","ufixed120x8","ufixed120x16","ufixed120x24","ufixed120x32","ufixed120x40","ufixed120x48","ufixed120x56","ufixed120x64","ufixed120x72","ufixed120x80","ufixed120x88","ufixed120x96","ufixed120x104","ufixed120x112","ufixed120x120","ufixed120x128","ufixed120x136","ufixed128x8","ufixed128x16","ufixed128x24","ufixed128x32","ufixed128x40","ufixed128x48","ufixed128x56","ufixed128x64","ufixed128x72","ufixed128x80","ufixed128x88","ufixed128x96","ufixed128x104","ufixed128x112","ufixed128x120","ufixed128x128","ufixed136x8","ufixed136x16","ufixed136x24","ufixed136x32","ufixed136x40","ufixed136x48","ufixed136x56","ufixed136x64","ufixed136x72","ufixed136x80","ufixed136x88","ufixed136x96","ufixed136x104","ufixed136x112","ufixed136x120","ufixed144x8","ufixed144x16","ufixed144x24","ufixed144x32","ufixed144x40","ufixed144x48","ufixed144x56","ufixed144x64","ufixed144x72","ufixed144x80","ufixed144x88","ufixed144x96","ufixed144x104","ufixed144x112","ufixed152x8","ufixed152x16","ufixed152x24","ufixed152x32","ufixed152x40","ufixed152x48","ufixed152x56","ufixed152x64","ufixed152x72","ufixed152x80","ufixed152x88","ufixed152x96","ufixed152x104","ufixed160x8","ufixed160x16","ufixed160x24","ufixed160x32","ufixed160x40","ufixed160x48","ufixed160x56","ufixed160x64","ufixed160x72","ufixed160x80","ufixed160x88","ufixed160x96","ufixed168x8","ufixed168x16","ufixed168x24","ufixed168x32","ufixed168x40","ufixed168x48","ufixed168x56","ufixed168x64","ufixed168x72","ufixed168x80","ufixed168x88","ufixed176x8","ufixed176x16","ufixed176x24","ufixed176x32","ufixed176x40","ufixed176x48","ufixed176x56","ufixed176x64","ufixed176x72","ufixed176x80","ufixed184x8","ufixed184x16","ufixed184x24","ufixed184x32","ufixed184x40","ufixed184x48","ufixed184x56","ufixed184x64","ufixed184x72","ufixed192x8","ufixed192x16","ufixed192x24","ufixed192x32","ufixed192x40","ufixed192x48","ufixed192x56","ufixed192x64","ufixed200x8","ufixed200x16","ufixed200x24","ufixed200x32","ufixed200x40","ufixed200x48","ufixed200x56","ufixed208x8","ufixed208x16","ufixed208x24","ufixed208x32","ufixed208x40","ufixed208x48","ufixed216x8","ufixed216x16","ufixed216x24","ufixed216x32","ufixed216x40","ufixed224x8","ufixed224x16","ufixed224x24","ufixed224x32","ufixed232x8","ufixed232x16","ufixed232x24","ufixed240x8","ufixed240x16","ufixed248x8","event","enum","let","mapping","private","public","external","inherited","payable","true","false","var","import","constant","if","else","for","else","for","while","do","break","continue","throw","returns","return","suicide","new","is","this","super"],operators:["=",">","<","!","~","?",":","==","<=",">=","!=","&&","||","++","--","+","-","*","/","&","|","^","%","<<",">>",">>>","+=","-=","*=","/=","&=","|=","^=","%=","<<=",">>=",">>>="],symbols:/[=>](?!@symbols)/,"@brackets"],[/@symbols/,{cases:{"@operators":"delimiter","@default":""}}],[/\d*\d+[eE]([\-+]?\d+)?(@floatsuffix)/,"number.float"],[/\d*\.\d+([eE][\-+]?\d+)?(@floatsuffix)/,"number.float"],[/0[xX][0-9a-fA-F']*[0-9a-fA-F](@integersuffix)/,"number.hex"],[/0[0-7']*[0-7](@integersuffix)/,"number.octal"],[/0[bB][0-1']*[0-1](@integersuffix)/,"number.binary"],[/\d[\d']*\d(@integersuffix)/,"number"],[/\d(@integersuffix)/,"number"],[/[;,.]/,"delimiter"],[/"([^"\\]|\\.)*$/,"string.invalid"],[/"/,"string","@string"],[/'[^\\']'/,"string"],[/(')(@escapes)(')/,["string","string.escape","string"]],[/'/,"string.invalid"]],whitespace:[[/[ \t\r\n]+/,""],[/\/\*\*(?!\/)/,"comment.doc","@doccomment"],[/\/\*/,"comment","@comment"],[/\/\/.*$/,"comment"]],comment:[[/[^\/*]+/,"comment"],[/\*\//,"comment","@pop"],[/[\/*]/,"comment"]],doccomment:[[/[^\/*]+/,"comment.doc"],[/\*\//,"comment.doc","@pop"],[/[\/*]/,"comment.doc"]],string:[[/[^\\"]+/,"string"],[/@escapes/,"string.escape"],[/\\./,"string.escape.invalid"],[/"/,"string","@pop"]]}}}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9748.e711e962.chunk.js.LICENSE.txt b/ydb/core/viewer/monitoring/static/js/98234.c2934def.chunk.js.LICENSE.txt similarity index 100% rename from ydb/core/viewer/monitoring/static/js/9748.e711e962.chunk.js.LICENSE.txt rename to ydb/core/viewer/monitoring/static/js/98234.c2934def.chunk.js.LICENSE.txt diff --git a/ydb/core/viewer/monitoring/static/js/98256.8a661541.chunk.js b/ydb/core/viewer/monitoring/static/js/98256.8a661541.chunk.js new file mode 100644 index 000000000000..a009254b91cd --- /dev/null +++ b/ydb/core/viewer/monitoring/static/js/98256.8a661541.chunk.js @@ -0,0 +1 @@ +"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[98256],{98256:(e,t,C)=>{C.r(t),C.d(t,{ReactComponent:()=>u,default:()=>E});var r,a,n,o,i,l,s,d,c,H,p,V,k,M=C(59284);function h(){return h=Object.assign?Object.assign.bind():function(e){for(var t=1;t{var a=t(51572);function o(e){e.register(a),e.languages.twig={comment:/^\{#[\s\S]*?#\}$/,"tag-name":{pattern:/(^\{%-?\s*)\w+/,lookbehind:!0,alias:"keyword"},delimiter:{pattern:/^\{[{%]-?|-?[%}]\}$/,alias:"punctuation"},string:{pattern:/("|')(?:\\.|(?!\1)[^\\\r\n])*\1/,inside:{punctuation:/^['"]|['"]$/}},keyword:/\b(?:even|if|odd)\b/,boolean:/\b(?:false|null|true)\b/,number:/\b0x[\dA-Fa-f]+|(?:\b\d+(?:\.\d*)?|\B\.\d+)(?:[Ee][-+]?\d+)?/,operator:[{pattern:/(\s)(?:and|b-and|b-or|b-xor|ends with|in|is|matches|not|or|same as|starts with)(?=\s)/,lookbehind:!0},/[=<>]=?|!=|\*\*?|\/\/?|\?:?|[-+~%|]/],punctuation:/[()\[\]{}:.,]/},e.hooks.add("before-tokenize",(function(n){if("twig"===n.language){e.languages["markup-templating"].buildPlaceholders(n,"twig",/\{(?:#[\s\S]*?#|%[\s\S]*?%|\{[\s\S]*?\})\}/g)}})),e.hooks.add("after-tokenize",(function(n){e.languages["markup-templating"].tokenizePlaceholders(n,"twig")}))}e.exports=o,o.displayName="twig",o.aliases=[]},51572:e=>{function n(e){!function(e){function n(e,n){return"___"+e.toUpperCase()+n+"___"}Object.defineProperties(e.languages["markup-templating"]={},{buildPlaceholders:{value:function(t,a,o,i){if(t.language===a){var r=t.tokenStack=[];t.code=t.code.replace(o,(function(e){if("function"===typeof i&&!i(e))return e;for(var o,s=r.length;-1!==t.code.indexOf(o=n(a,s));)++s;return r[s]=e,o})),t.grammar=e.languages.markup}}},tokenizePlaceholders:{value:function(t,a){if(t.language===a&&t.tokenStack){t.grammar=e.languages[a];var o=0,i=Object.keys(t.tokenStack);!function r(s){for(var u=0;u=i.length);u++){var l=s[u];if("string"===typeof l||l.content&&"string"===typeof l.content){var g=i[o],d=t.tokenStack[g],c="string"===typeof l?l:l.content,p=n(a,g),f=c.indexOf(p);if(f>-1){++o;var k=c.substring(0,f),b=new e.Token(a,e.tokenize(d,t.grammar),"language-"+a,d),m=c.substring(f+p.length),h=[];k&&h.push.apply(h,r([k])),h.push(b),m&&h.push.apply(h,r([m])),"string"===typeof l?s.splice.apply(s,[u,1].concat(h)):l.content=h}}else l.content&&r(l.content)}return s}(t.tokens)}}}})}(e)}e.exports=n,n.displayName="markupTemplating",n.aliases=[]},98268:(e,n,t)=>{t.d(n,{default:()=>o});var a=t(34073);const o=t.n(a)()}}]); \ No newline at end of file diff --git a/ydb/core/viewer/monitoring/static/js/9842.b8ba19ad.chunk.js b/ydb/core/viewer/monitoring/static/js/9842.b8ba19ad.chunk.js deleted file mode 100644 index ae741ddd5425..000000000000 --- a/ydb/core/viewer/monitoring/static/js/9842.b8ba19ad.chunk.js +++ /dev/null @@ -1,2 +0,0 @@ -/*! For license information please see 9842.b8ba19ad.chunk.js.LICENSE.txt */ -"use strict";(globalThis.webpackChunkydb_embedded_ui=globalThis.webpackChunkydb_embedded_ui||[]).push([[9842],{79842:(e,r,i)=>{i.r(r),i.d(r,{conf:()=>t,language:()=>s});var t={comments:{lineComment:"#"},brackets:[["{","}"],["[","]"],["(",")"]],autoClosingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}]},s={defaultToken:"",ignoreCase:!0,tokenPostfix:".shell",brackets:[{token:"delimiter.bracket",open:"{",close:"}"},{token:"delimiter.parenthesis",open:"(",close:")"},{token:"delimiter.square",open:"[",close:"]"}],keywords:["if","then","do","else","elif","while","until","for","in","esac","fi","fin","fil","done","exit","set","unset","export","function"],builtins:["ab","awk","bash","beep","cat","cc","cd","chown","chmod","chroot","clear","cp","curl","cut","diff","echo","find","gawk","gcc","get","git","grep","hg","kill","killall","ln","ls","make","mkdir","openssl","mv","nc","node","npm","ping","ps","restart","rm","rmdir","sed","service","sh","shopt","shred","source","sort","sleep","ssh","start","stop","su","sudo","svn","tee","telnet","top","touch","vi","vim","wall","wc","wget","who","write","yes","zsh"],startingWithDash:/\-+\w+/,identifiersWithDashes:/[a-zA-Z]\w+(?:@startingWithDash)+/,symbols:/[=>{"use strict";i.d(t,{A:()=>o});var s,n=i(59284);function r(){return r=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{A:()=>o});var s,n=i(59284);function r(){return r=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{A:()=>o});var s,n=i(59284);function r(){return r=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{A:()=>a});var s,n,r=i(59284);function o(){return o=Object.assign?Object.assign.bind():function(e){for(var t=1;t{"use strict";i.d(t,{R:()=>a,J:()=>o});var s=i(1448);const n=JSON.parse('{"common":{"tooltip-sum":"Sum","tooltip-rest":"Rest"},"chartkit":{"error":"Error","legend-series-hide":"Hide all lines","legend-series-show":"Show all lines","tooltip-point-format-size":"Size","tooltip-sum":"Sum","tooltip-rest":"Rest","error-incorrect-key-value-intro":"Incorrect notation of an object passed to","error-incorrect-key":", object keys must be convertible to integer","error-incorrect-value":", object values must be a string or a function which returns a string"},"chartkit-table":{"message-no-data":"No data","paginator-rows":"Rows"},"chartkit-ymap-legend":{"label-more":"Show more {{count}}","label-hide":"Hide","label-heatmap":"Heatmap"},"error":{"label_no-data":"No data","label_unknown-plugin":"Unknown plugin type \\"{{type}}\\"","label_unknown-error":"Unknown error","label_invalid-axis-category-data-point":"It seems you are trying to use inappropriate data type for \\"{{key}}\\" value in series \\"{{seriesName}}\\" for axis with type \\"category\\". Strings and numbers are allowed.","label_invalid-axis-datetime-data-point":"It seems you are trying to use inappropriate data type for \\"{{key}}\\" value in series \\"{{seriesName}}\\" for axis with type \\"datetime\\". Only numbers are allowed.","label_invalid-axis-linear-data-point":"It seems you are trying to use inappropriate data type for \\"{{key}}\\" value in series \\"{{seriesName}}\\" for axis with type \\"linear\\". Numbers and nulls are allowed.","label_invalid-pie-data-value":"It seems you are trying to use inappropriate data type for \\"value\\" value. Only numbers are allowed.","label_invalid-series-type":"It seems you haven\'t defined \\"series.type\\" property, or defined it incorrectly. Available values: [{{types}}].","label_invalid-series-property":"It seems you are trying to use inappropriate value for \\"{{key}}\\", or defined it incorrectly. Available values: [{{values}}].","label_invalid-treemap-redundant-value":"It seems you are trying to set \\"value\\" for container node. Check node with this properties: { id: \\"{{id}}\\", name: \\"{{name}}\\" }","label_invalid-treemap-missing-value":"It seems you are trying to use node without \\"value\\". Check node with this properties: { id: \\"{{id}}\\", name: \\"{{name}}\\" }","label_invalid-y-axis-index":"It seems you are trying to use inappropriate index for Y axis: \\"{{index}}\\""},"highcharts":{"reset-zoom-title":"Reset zoom","decimal-point":".","thousands-sep":" ","Mon":"Mon","Tue":"Tue","Wed":"Wed","Thu":"Thu","Fri":"Fri","Sat":"Sat","Sun":"Sun","Jan":"Jan","January":"January","Feb":"Feb","February":"February","Mar":"Mar","March":"March","Apr":"Apr","April":"April","May":"May","Jun":"Jun","June":"June","Jul":"Jul","July":"July","Aug":"Aug","August":"August","Sep":"Sep","September":"September","Oct":"Oct","October":"October","Nov":"Nov","November":"November","Dec":"Dec","December":"December"}}'),r=JSON.parse('{"common":{"tooltip-sum":"\u0421\u0443\u043c\u043c\u0430","tooltip-rest":"\u041e\u0441\u0442\u0430\u043b\u044c\u043d\u044b\u0435"},"chartkit":{"error":"\u041e\u0448\u0438\u0431\u043a\u0430","legend-series-hide":"\u0421\u043a\u0440\u044b\u0442\u044c \u0432\u0441\u0435 \u043b\u0438\u043d\u0438\u0438","legend-series-show":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0432\u0441\u0435 \u043b\u0438\u043d\u0438\u0438","loading":"\u0417\u0430\u0433\u0440\u0443\u0437\u043a\u0430","tooltip-point-format-size":"\u0420\u0430\u0437\u043c\u0435\u0440","tooltip-sum":"\u0421\u0443\u043c\u043c\u0430","tooltip-rest":"\u041e\u0441\u0442\u0430\u043b\u044c\u043d\u044b\u0435","error-incorrect-key-value-intro":"\u041d\u0435\u043a\u043e\u0440\u0440\u0435\u043a\u0442\u043d\u044b\u0439 \u0444\u043e\u0440\u043c\u0430\u0442 \u043e\u0431\u044a\u0435\u043a\u0442\u0430 \u043f\u0435\u0440\u0435\u0434\u0430\u043d\u043d\u043e\u0433\u043e \u043a\u0430\u043a \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0432","error-incorrect-key":", \u043a\u043b\u044e\u0447\u0438 \u043e\u0431\u044a\u0435\u043a\u0442\u0430 \u0434\u043e\u043b\u0436\u043d\u044b \u0431\u044b\u0442\u044c \u043f\u0440\u0435\u043e\u0431\u0440\u0430\u0437\u0443\u0435\u043c\u044b \u0432 \u0446\u0435\u043b\u043e\u0435 \u0447\u0438\u0441\u043b\u043e","error-incorrect-value":", \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435\u043c \u043e\u0431\u044a\u0435\u043a\u0442\u0430 \u043c\u043e\u0436\u0435\u0442 \u0431\u044b\u0442\u044c \u043b\u0438\u0431\u043e \u0441\u0442\u0440\u043e\u043a\u0430, \u043b\u0438\u0431\u043e \u0444\u0443\u043d\u043a\u0446\u0438\u044f \u0432\u043e\u0437\u0432\u0440\u0430\u0449\u0430\u044e\u0449\u0430\u044f \u0441\u0442\u0440\u043e\u043a\u0443"},"chartkit-table":{"message-no-data":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445","paginator-rows":"\u0421\u0442\u0440\u043e\u043a\u0438"},"chartkit-ymap-legend":{"label-more":"\u041f\u043e\u043a\u0430\u0437\u0430\u0442\u044c \u0435\u0449\u0451 {{count}}","label-hide":"\u0421\u0432\u0435\u0440\u043d\u0443\u0442\u044c","label-heatmap":"\u0422\u0435\u043f\u043b\u043e\u0432\u0430\u044f \u043a\u0430\u0440\u0442\u0430"},"error":{"label_no-data":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445","label_unknown-plugin":"\u041d\u0435\u0438\u0437\u0432\u0435\u0441\u0442\u043d\u044b\u0439 \u0442\u0438\u043f \u043f\u043b\u0430\u0433\u0438\u043d\u0430 \\"{{type}}\\"","label_unknown-error":"\u041d\u0435\u0438\u0437\u0432\u0435\u0441\u0442\u043d\u0430\u044f \u043e\u0448\u0438\u0431\u043a\u0430","label_invalid-axis-category-data-point":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u043d\u0435\u0434\u043e\u043f\u0443\u0441\u0442\u0438\u043c\u044b\u0439 \u0442\u0438\u043f \u0434\u0430\u043d\u043d\u044b\u0445 \u0434\u043b\u044f \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f \\"{{key}}\\" \u0432 \u0441\u0435\u0440\u0438\u0438 \\"{{seriesName}}\\" \u0434\u043b\u044f \u043e\u0441\u0438 \u0441 \u0442\u0438\u043f\u043e\u043c \\"category\\". \u0414\u043e\u043f\u0443\u0441\u043a\u0430\u0435\u0442\u0441\u044f \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u043d\u0438\u0435 \u0441\u0442\u0440\u043e\u043a \u0438 \u0447\u0438\u0441\u0435\u043b.","label_invalid-axis-datetime-data-point":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u043d\u0435\u0434\u043e\u043f\u0443\u0441\u0442\u0438\u043c\u044b\u0439 \u0442\u0438\u043f \u0434\u0430\u043d\u043d\u044b\u0445 \u0434\u043b\u044f \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f \\"{{key}}\\" \u0432 \u0441\u0435\u0440\u0438\u0438 \\"{{seriesName}}\\" \u0434\u043b\u044f \u043e\u0441\u0438 \u0441 \u0442\u0438\u043f\u043e\u043c \\"datetime\\". \u0414\u043e\u043f\u0443\u0441\u043a\u0430\u0435\u0442\u0441\u044f \u0442\u043e\u043b\u044c\u043a\u043e \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u043d\u0438\u0435 \u0447\u0438\u0441\u0435\u043b.","label_invalid-axis-linear-data-point":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u043d\u0435\u0434\u043e\u043f\u0443\u0441\u0442\u0438\u043c\u044b\u0439 \u0442\u0438\u043f \u0434\u0430\u043d\u043d\u044b\u0445 \u0434\u043b\u044f \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f \\"{{key}}\\" \u0432 \u0441\u0435\u0440\u0438\u0438 \\"{{seriesName}}\\" \u0434\u043b\u044f \u043e\u0441\u0438 \u0441 \u0442\u0438\u043f\u043e\u043c \\"linear\\". \u0414\u043e\u043f\u0443\u0441\u043a\u0430\u0435\u0442\u0441\u044f \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u043d\u0438\u0435 \u0447\u0438\u0441\u0435\u043b \u0438 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0439 null.","label_invalid-pie-data-value":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u043d\u0435\u0434\u043e\u043f\u0443\u0441\u0442\u0438\u043c\u044b\u0439 \u0442\u0438\u043f \u0434\u0430\u043d\u043d\u044b\u0445 \u0434\u043b\u044f \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f \\"value\\". \u0414\u043e\u043f\u0443\u0441\u043a\u0430\u0435\u0442\u0441\u044f \u0442\u043e\u043b\u044c\u043a\u043e \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u043d\u0438\u0435 \u0447\u0438\u0441\u0435\u043b.","label_invalid-series-type":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043d\u0435 \u0443\u043a\u0430\u0437\u0430\u043b\u0438 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \\"series.type\\" \u0438\u043b\u0438 \u0443\u043a\u0430\u0437\u0430\u043b\u0438 \u0435\u0433\u043e \u043d\u0435\u0432\u0435\u0440\u043d\u043e. \u0414\u043e\u0441\u0442\u0443\u043f\u043d\u044b\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f: [{{types}}].","label_invalid-series-property":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u043d\u0435\u0434\u043e\u043f\u0443\u0441\u0442\u0438\u043c\u043e\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u0434\u043b\u044f \\"{{key}}\\", \u0438\u043b\u0438 \u0443\u043a\u0430\u0437\u0430\u043b\u0438 \u0435\u0433\u043e \u043d\u0435\u0432\u0435\u0440\u043d\u043e. \u0414\u043e\u0441\u0442\u0443\u043f\u043d\u044b\u0435 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f: [{{values}}].","label_invalid-treemap-redundant-value":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0443\u0441\u0442\u0430\u043d\u043e\u0432\u0438\u0442\u044c \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \\"value\\" \u0434\u043b\u044f \u0443\u0437\u043b\u0430, \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u0443\u0435\u043c\u043e\u0433\u043e \u0432 \u043a\u0430\u0447\u0435\u0441\u0442\u0432\u0435 \u043a\u043e\u043d\u0442\u0435\u0439\u043d\u0435\u0440\u0430. \u041f\u0440\u043e\u0432\u0435\u0440\u044c\u0442\u0435 \u0443\u0437\u0435\u043b \u0441 \u044d\u0442\u0438\u043c\u0438 \u0441\u0432\u043e\u0439\u0441\u0442\u0432\u0430\u043c\u0438: { id: \\"{{id}}\\", name: \\"{{name}}\\" }","label_invalid-treemap-missing-value":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u0443\u0437\u0435\u043b \u0431\u0435\u0437 \u0437\u043d\u0430\u0447\u0435\u043d\u0438\u044f \\"value\\". \u041f\u0440\u043e\u0432\u0435\u0440\u044c\u0442\u0435 \u0443\u0437\u0435\u043b \u0441 \u044d\u0442\u0438\u043c\u0438 \u0441\u0432\u043e\u0439\u0441\u0442\u0432\u0430\u043c\u0438: { id: \\"{{id}}\\", name: \\"{{name}}\\" }","label_invalid-y-axis-index":"\u041f\u043e\u0445\u043e\u0436\u0435, \u0447\u0442\u043e \u0432\u044b \u043f\u044b\u0442\u0430\u0435\u0442\u0435\u0441\u044c \u0438\u0441\u043f\u043e\u043b\u044c\u0437\u043e\u0432\u0430\u0442\u044c \u043d\u0435\u043a\u043e\u0440\u0440\u0435\u043a\u0442\u043d\u044b\u0439 \u0438\u043d\u0434\u0435\u043a\u0441 \u0434\u043b\u044f \u043e\u0441\u0438 Y: \\"{{index}}\\""},"highcharts":{"reset-zoom-title":"\u0421\u0431\u0440\u043e\u0441\u0438\u0442\u044c \u0443\u0432\u0435\u043b\u0438\u0447\u0435\u043d\u0438\u0435","decimal-point":",","thousands-sep":" ","Mon":"\u041f\u043d","Tue":"\u0412\u0442","Wed":"\u0421\u0440","Thu":"\u0427\u0442","Fri":"\u041f\u0442","Sat":"\u0421\u0431","Sun":"\u0412\u0441","Jan":"\u042f\u043d\u0432","January":"\u042f\u043d\u0432\u0430\u0440\u044c","Feb":"\u0424\u0435\u0432","February":"\u0424\u0435\u0432\u0440\u0430\u043b\u044c","Mar":"\u041c\u0430\u0440","March":"\u041c\u0430\u0440\u0442","Apr":"\u0410\u043f\u0440","April":"\u0410\u043f\u0440\u0435\u043b\u044c","May":"\u041c\u0430\u0439","Jun":"\u0418\u044e\u043d","June":"\u0418\u044e\u043d\u044c","Jul":"\u0418\u044e\u043b","July":"\u0418\u044e\u043b\u044c","Aug":"\u0410\u0432\u0433","August":"\u0410\u0432\u0433\u0443\u0441\u0442","Sep":"\u0421\u0435\u043d","September":"\u0421\u0435\u043d\u0442\u044f\u0431\u0440\u044c","Oct":"\u041e\u043a\u0442","October":"\u041e\u043a\u0442\u044f\u0431\u0440\u044c","Nov":"\u041d\u043e\u044f","November":"\u041d\u043e\u044f\u0431\u0440\u044c","Dec":"\u0414\u0435\u043a","December":"\u0414\u0435\u043a\u0430\u0431\u0440\u044c"}}'),o=new s.TH;o.registerKeysets("en",n),o.registerKeysets("ru",r);const a=o.i18n.bind(o)},40014:(e,t,i)=>{"use strict";i.d(t,{Ay:()=>C});var s=i(27145),n=i(59284),r=i(8964),o=i(66643),a=i(42392);const l=()=>`ck.${((e,t)=>{let i="";for(let s=e;s>0;--s)i+=t[Math.floor(Math.random()*t.length)];return i})(10,"0123456789abcdefghijklmnopqrstuvwxyz")}`,c=n.memo;var h=i(82435);const d=(0,h.withNaming)({e:"__",m:"_"}),u=(0,h.withNaming)({n:"chartkit-",e:"__",m:"_"});class g extends n.Component{constructor(){super(...arguments),this.state={error:void 0},this.resetError=()=>{this.state.error&&this.setState({error:void 0})}}static getDerivedStateFromError(e){return{error:e}}componentDidCatch(){var e,t;const{error:i}=this.state;i&&(null===(t=(e=this.props).onError)||void 0===t||t.call(e,{error:i}))}componentDidUpdate(e){if(e.data!==this.props.data){const{error:e}=this.state;e&&"code"in e&&e.code===a.iY.NO_DATA&&this.resetError()}}render(){const{error:e}=this.state;if(e){const t=function(e){const t="code"in e&&e.code;return(e.message||t||(0,r.R)("error","label_unknown-error")).toString()}(e);return this.props.renderError?this.props.renderError({error:e,message:t,resetError:this.resetError}):n.createElement("div",null,t)}return this.props.children}}var p=i(74417);const m=u("loader"),f=e=>{var{renderPluginLoader:t}=e,i=(0,s.Tt)(e,["renderPluginLoader"]);const r=null===t||void 0===t?void 0:t();return"undefined"!==typeof r?r:n.createElement("div",{className:m()},n.createElement(p.a,Object.assign({},i)))},_=d("chartkit"),v=e=>{const t=n.useRef(),{instanceRef:i,id:c,type:h,isMobile:d,renderPluginLoader:u}=e,g=(0,s.Tt)(e,["instanceRef","id","type","isMobile","renderPluginLoader"]),p=n.useMemo((()=>l()),[]),m=c||p,v=o.W.get("lang"),C=o.W.get("plugins").find((e=>e.type===h));if(!C)throw new a.R({code:a.iY.UNKNOWN_PLUGIN,message:(0,r.R)("error","label_unknown-plugin",{type:h})});const b=C.renderer;return n.useImperativeHandle(i,(()=>({reflow(e){var i;(null===(i=t.current)||void 0===i?void 0:i.reflow)&&t.current.reflow(e)}})),[]),n.createElement(n.Suspense,{fallback:n.createElement(f,{renderPluginLoader:u})},n.createElement("div",{className:_({mobile:d},"chartkit-theme_common")},n.createElement(b,Object.assign({ref:t,id:m,lang:v},g))))},C=c(n.forwardRef((function(e,t){return n.createElement(g,{onError:e.onError,data:e.data,renderError:e.renderError},n.createElement(v,Object.assign({instanceRef:t},e)))})))},42392:(e,t,i)=>{"use strict";i.d(t,{R:()=>n,iY:()=>s});const s={NO_DATA:"ERR.CK.NO_DATA",INVALID_DATA:"ERR.CK.INVALID_DATA",UNKNOWN:"ERR.CK.UNKNOWN_ERROR",UNKNOWN_PLUGIN:"ERR.CK.UNKNOWN_PLUGIN",TOO_MANY_LINES:"ERR.CK.TOO_MANY_LINES"};class n extends Error{constructor({originalError:e,message:t,code:i=s.UNKNOWN}={}){super(t),this.isCustomError=!0,this.code=i,e&&(this.name=e.name,this.stack=e.stack)}}},66643:(e,t,i)=>{"use strict";i.d(t,{W:()=>p});var s=i(3357),n=i(87924),r=i.n(n),o=i(52708),a=i.n(o),l=i(8964);var c=i(38469),h=i.n(c);function d(e,t,i){if("plugins"===i){const i=[...e],s=[...t];let n=i.map((e=>{const t=s.findIndex((({type:t})=>t===e.type));if(-1!==t){const i=s[t];return s.splice(t,1),{type:e.type,renderer:i.renderer}}return e}));return s.length>0&&(n=[...n,...s]),n}return h()(e)?a()(e,t,d):t}const u=new class{constructor(){this.events={}}on(e,t){this.events[e]?this.events[e].push(t):this.events[e]=[t]}off(e,t){this.events[e]&&(this.events[e]=this.events[e].filter((({id:e})=>e!==t)))}dispatch(e,t){this.events[e]&&this.events[e].forEach((({action:e})=>{e(t)}))}},g=e=>{(0,s.jK)({lang:e}),l.J.setLang(e)};const p=new class{constructor(){this.settings={plugins:[],lang:"en"},g(this.get("lang"))}get(e){return r()(this.settings,e)}set(e){const t=(i=e,Object.entries(i).reduce(((e,[t,i])=>("undefined"!==typeof i&&(e[t]=i),e)),{}));var i;if(this.settings=a()(this.settings,t,d),t.lang){const e=t.lang||this.get("lang");g(e),u.dispatch("change-lang",e)}}}},25533:(e,t,i)=>{"use strict";i.d(t,{YagrPlugin:()=>s});const s={type:"yagr",renderer:i(59284).lazy((()=>Promise.all([i.e(1836),i.e(8593)]).then(i.bind(i,81836))))}},57439:(e,t,i)=>{"use strict";i.d(t,{u:()=>w});var s=i(59284),n=i(96873),r=i(98192);const o=(0,r.om)("definition-list");const a=e=>"label"in e&&!("name"in e),l=e=>!e.some((e=>a(e)));function c(e,t){return e||("string"===typeof t||"number"===typeof t?String(t):void 0)}function h({copyText:e,content:t,copyPosition:i}){const r="inside"===i,a=null!==t&&void 0!==t?t:"\u2014";return e?s.createElement("div",{className:o("copy-container",{"icon-inside":r})},s.createElement("span",null,a),s.createElement(n.b,{size:"s",text:e,className:o("copy-button"),view:r?"raised":"flat-secondary"})):a}var d=i(98089);function u({label:e}){return s.createElement("div",{className:o("group-title")},s.createElement(d.E,{variant:"subheader-1",color:"complementary"},e))}var g=i(6170),p=i(72837);const m=JSON.parse('{"label_note":"Note"}'),f=JSON.parse('{"label_note":"\u0421\u043f\u0440\u0430\u0432\u043a\u0430"}'),_=(0,p.N)({en:m,ru:f},`${r.CU}definition-list`);var v=function(e,t){var i={};for(var s in e)Object.prototype.hasOwnProperty.call(e,s)&&t.indexOf(s)<0&&(i[s]=e[s]);if(null!=e&&"function"===typeof Object.getOwnPropertySymbols){var n=0;for(s=Object.getOwnPropertySymbols(e);ne.map(((e,t)=>Object.assign(Object.assign({},e),{key:t})))),[e]);return s.createElement("div",{className:o({responsive:t,vertical:"vertical"===i},a),"data-qa":u},s.createElement("dl",{className:o("list")},m.map((e=>{const{name:t,key:n,content:r,contentTitle:a,nameTitle:u,copyText:m,note:f,multilineName:_}=e;return s.createElement("div",{key:n,className:o("item",l)},s.createElement("dt",{className:o("term-container",{multiline:_}),style:g},s.createElement(b,{direction:i,name:t,nameTitle:u,note:f,multilineName:_})),s.createElement("dd",{className:o("definition"),title:c(a,r),style:Object.assign(Object.assign({},p),{lineBreak:"string"===typeof r&&(v=20,function(e){return e.split(/\s+/).some((e=>e.length>v))})(r)?"anywhere":void 0})},s.createElement(h,{copyPosition:d,copyText:m,content:r})));var v}))))}function y(e){var{items:t,className:i,itemClassName:n}=e,r=E(e,["items","className","itemClassName"]);const a=s.useMemo((()=>t.map(((e,t)=>Object.assign(Object.assign({},e),{key:t})))),[t]);return s.createElement("div",{className:o({vertical:"vertical"===r.direction},i)},a.map((e=>{const{key:t,label:i}=e;return s.createElement(s.Fragment,{key:t},i&&s.createElement(u,{label:i}),e.items&&s.createElement(S,Object.assign({},r,{className:o({margin:!i}),items:e.items,itemClassName:o("item",{grouped:Boolean(i)},n)})))})))}function w(e){var{items:t}=e,i=E(e,["items"]);if(l(t))return s.createElement(S,Object.assign({},i,{items:t}));const n=function(e){const t=[];let i=[];for(const s of e)a(s)?(i.length&&(t.push({items:i,label:null}),i=[]),t.push(s)):i.push(s);return i.length&&(t.push({items:i,label:null}),i=[]),t}(t);return s.createElement(y,Object.assign({},i,{items:n}))}},6170:(e,t,i)=>{"use strict";i.d(t,{B:()=>c});var s=i(59284),n=i(73633),r=i(84375),o=i(99991);const a=(0,i(98192).om)("help-popover"),l=16;function c(e){var t;return s.createElement(r.A,Object.assign({},e,{className:a(null,e.className)}),s.createElement("button",Object.assign({ref:e.buttonRef,type:"button"},e.buttonProps,{className:a("button",null===(t=e.buttonProps)||void 0===t?void 0:t.className)}),s.createElement(o.I,{data:n.A,size:l})))}},98192:(e,t,i)=>{"use strict";i.d(t,{CU:()=>n,om:()=>r});var s=i(82435);const n="gc-",r=((0,s.withNaming)({e:"__",m:"_",v:"_"}),(0,s.withNaming)({n:n,e:"__",m:"_",v:"_"}))},23812:(e,t,i)=>{"use strict";i.d(t,{k:()=>ai});var s=i(60712),n=i(59284),r=i(46819),o=i(85736),a=i(51301);const l="g-date-",c=(0,i(82435).withNaming)({n:l,e:"__",m:"_"});function h({name:e,value:t,onReset:i,form:r,disabled:o,toStringValue:a}){const l=function({initialValue:e,onReset:t}){const[i,s]=n.useState(null),r=n.useRef(e);n.useEffect((()=>{if(!i||!t)return;const e=()=>{t(r.current)};return i.addEventListener("reset",e),()=>{i.removeEventListener("reset",e)}}),[i,t]);const o=n.useCallback((e=>{var t;s(null!==(t=null===e||void 0===e?void 0:e.form)&&void 0!==t?t:null)}),[]);return o}({initialValue:t,onReset:i});if(!e)return null;const c=a?a(t):`${null!==t&&void 0!==t?t:""}`;return(0,s.jsx)("input",{ref:l,type:"hidden",name:e,value:c,disabled:o,form:r})}const d=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M5.25 5.497a.75.75 0 0 1-.75-.75V4A1.5 1.5 0 0 0 3 5.5v1h10v-1A1.5 1.5 0 0 0 11.5 4v.75a.75.75 0 0 1-1.5 0V4H6v.747a.75.75 0 0 1-.75.75M10 2.5H6v-.752a.75.75 0 1 0-1.5 0V2.5a3 3 0 0 0-3 3v6a3 3 0 0 0 3 3h7a3 3 0 0 0 3-3v-6a3 3 0 0 0-3-3v-.75a.75.75 0 0 0-1.5 0zM3 8v3.5A1.5 1.5 0 0 0 4.5 13h7a1.5 1.5 0 0 0 1.5-1.5V8z",clipRule:"evenodd"}));var u=i(28664),g=i(84476),p=i(99991);function m(e){switch(e){case"xl":return"l";case"l":return"m";case"s":return"xs";default:return"s"}}var f=i(14750),_=i(72837);const v=JSON.parse('{"Last 5 minutes":"Last 5 minutes","Last 15 minutes":"Last 15 minutes","Last 30 minutes":"Last 30 minutes","Last hour":"Last hour","Last 3 hours":"Last 3 hours","Last 6 hours":"Last 6 hours","Last 12 hours":"Last 12 hours","Last day":"Last day","Last 3 days":"Last 3 days","Last week":"Last week","Last month":"Last month","Last 3 months":"Last 3 months","Last 6 months":"Last 6 months","Last year":"Last year","Last 3 years":"Last 3 years","Today":"Today","Yesterday":"Yesterday","Day before yesterday":"Day before yesterday","This week":"This week","This month":"This month","This year":"This year","From start of day":"From start of day","From start of week":"From start of week","From start of month":"From start of month","From start of year":"From start of year","Previous month":"Previous month","Last second":"Last second","Last minute":"Last minute","Last {count} second":["Last {{count}} second","Last {{count}} seconds","Last {{count}} seconds"],"Last {count} minute":["Last {{count}} minute","Last {{count}} minutes","Last {{count}} minutes"],"Last {count} hour":["Last {{count}} hour","Last {{count}} hours","Last {{count}} hours"],"Last {count} day":["Last {{count}} day","Last {{count}} days","Last {{count}} days"],"Last {count} week":["Last {{count}} week","Last {{count}} weeks","Last {{count}} weeks"],"Last {count} month":["Last {{count}} month","Last {{count}} months","Last {{count}} months"],"Last {count} year":["Last {{count}} year","Last {{count}} years","Last {{count}} years"],"Main":"Main","Other":"Other","Range":"Range","From":"From","To":"To"}'),C=JSON.parse('{"Last 5 minutes":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 5 \u043c\u0438\u043d\u0443\u0442","Last 15 minutes":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 15 \u043c\u0438\u043d\u0443\u0442","Last 30 minutes":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 30 \u043c\u0438\u043d\u0443\u0442","Last hour":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 \u0447\u0430\u0441","Last 3 hours":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 3 \u0447\u0430\u0441\u0430","Last 6 hours":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 6 \u0447\u0430\u0441\u043e\u0432","Last 12 hours":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 12 \u0447\u0430\u0441\u043e\u0432","Last day":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 \u0434\u0435\u043d\u044c","Last 3 days":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 3 \u0434\u043d\u044f","Last week":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u044f\u044f \u043d\u0435\u0434\u0435\u043b\u044f","Last month":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 \u043c\u0435\u0441\u044f\u0446","Last 3 months":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 3 \u043c\u0435\u0441\u044f\u0446\u0430","Last 6 months":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 6 \u043c\u0435\u0441\u044f\u0446\u0435\u0432","Last year":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 \u0433\u043e\u0434","Last 3 years":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 3 \u0433\u043e\u0434\u0430","Today":"\u0421\u0435\u0433\u043e\u0434\u043d\u044f","Yesterday":"\u0412\u0447\u0435\u0440\u0430","Day before yesterday":"\u041f\u043e\u0437\u0430\u0432\u0447\u0435\u0440\u0430","This week":"\u042d\u0442\u0430 \u043d\u0435\u0434\u0435\u043b\u044f","This month":"\u042d\u0442\u043e\u0442 \u043c\u0435\u0441\u044f\u0446","This year":"\u042d\u0442\u043e\u0442 \u0433\u043e\u0434","From start of day":"\u0421 \u043d\u0430\u0447\u0430\u043b\u0430 \u0434\u043d\u044f","From start of week":"\u0421 \u043d\u0430\u0447\u0430\u043b\u0430 \u043d\u0435\u0434\u0435\u043b\u0438","From start of month":"\u0421 \u043d\u0430\u0447\u0430\u043b\u0430 \u043c\u0435\u0441\u044f\u0446\u0430","From start of year":"\u0421 \u043d\u0430\u0447\u0430\u043b\u0430 \u0433\u043e\u0434\u0430","Previous month":"\u041f\u0440\u0435\u0434\u044b\u0434\u0443\u0449\u0438\u0439 \u043c\u0435\u0441\u044f\u0446","Last second":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u044f\u044f \u0441\u0435\u043a\u0443\u043d\u0434\u0430","Last minute":"\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u044f\u044f \u043c\u0438\u043d\u0443\u0442\u0430","Last {count} second":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u044f\u044f {{count}} \u0441\u0435\u043a\u0443\u043d\u0434\u0430","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0441\u0435\u043a\u0443\u043d\u0434\u044b","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0441\u0435\u043a\u0443\u043d\u0434"],"Last {count} minute":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u044f\u044f {{count}} \u043c\u0438\u043d\u0443\u0442\u0430","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043c\u0438\u043d\u0443\u0442\u044b","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043c\u0438\u043d\u0443\u0442"],"Last {count} hour":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 {{count}} \u0447\u0430\u0441","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0447\u0430\u0441\u0430","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0447\u0430\u0441\u043e\u0432"],"Last {count} day":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 {{count}} \u0434\u0435\u043d\u044c","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0434\u043d\u044f","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0434\u043d\u0435\u0439"],"Last {count} week":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u044f\u044f {{count}} \u043d\u0435\u0434\u0435\u043b\u044f","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043d\u0435\u0434\u0435\u043b\u0438","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043d\u0435\u0434\u0435\u043b\u044c"],"Last {count} month":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 {{count}} \u043c\u0435\u0441\u044f\u0446","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043c\u0435\u0441\u044f\u0446\u0430","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043c\u0435\u0441\u044f\u0446\u0435\u0432"],"Last {count} year":["\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0439 {{count}} \u0433\u043e\u0434","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u0433\u043e\u0434\u0430","\u041f\u043e\u0441\u043b\u0435\u0434\u043d\u0438\u0435 {{count}} \u043b\u0435\u0442"],"Main":"\u041e\u0441\u043d\u043e\u0432\u043d\u044b\u0435","Other":"\u0414\u0440\u0443\u0433\u0438\u0435","Range":"\u041f\u0435\u0440\u0438\u043e\u0434","From":"\u041e\u0442","To":"\u0414\u043e"}'),b=(0,_.N)({en:v,ru:C},`${l}relative-range-date-picker-presets`),E=[{from:"now-1d",to:"now",get title(){return b("Last day")}},{from:"now-3d",to:"now",get title(){return b("Last 3 days")}},{from:"now-1w",to:"now",get title(){return b("Last week")}},{from:"now-1M",to:"now",get title(){return b("Last month")}},{from:"now-3M",to:"now",get title(){return b("Last 3 months")}},{from:"now-6M",to:"now",get title(){return b("Last 6 months")}},{from:"now-1y",to:"now",get title(){return b("Last year")}},{from:"now-3y",to:"now",get title(){return b("Last 3 years")}}],S=[{from:"now-5m",to:"now",get title(){return b("Last 5 minutes")}},{from:"now-15m",to:"now",get title(){return b("Last 15 minutes")}},{from:"now-30m",to:"now",get title(){return b("Last 30 minutes")}},{from:"now-1h",to:"now",get title(){return b("Last hour")}},{from:"now-3h",to:"now",get title(){return b("Last 3 hours")}},{from:"now-6h",to:"now",get title(){return b("Last 6 hours")}},{from:"now-12h",to:"now",get title(){return b("Last 12 hours")}}],y=[{from:"now/d",to:"now/d",get title(){return b("Today")}},{from:"now-1d/d",to:"now-1d/d",get title(){return b("Yesterday")}},{from:"now-2d/d",to:"now-2d/d",get title(){return b("Day before yesterday")}},{from:"now/w",to:"now/w",get title(){return b("This week")}},{from:"now/M",to:"now/M",get title(){return b("This month")}},{from:"now/y",to:"now/y",get title(){return b("This year")}},{from:"now/d",to:"now",get title(){return b("From start of day")}},{from:"now/w",to:"now",get title(){return b("From start of week")}},{from:"now/M",to:"now",get title(){return b("From start of month")}},{from:"now/y",to:"now",get title(){return b("From start of year")}}],w=S.concat(E,y),L=/^now-(\d+)([smhdwMy])$/,R={s:"Last second",m:"Last minute",h:"Last hour",d:"Last day",w:"Last week",M:"Last month",y:"Last year"},T={s:"Last {count} second",m:"Last {count} minute",h:"Last {count} hour",d:"Last {count} day",w:"Last {count} week",M:"Last {count} month",y:"Last {count} year"};function x(e,t){return e.filter((e=>{const i=(0,f.bQ)(e.from),s=(0,f.bQ)(e.to,{roundUp:!0});return!(!i||!s)&&(!s.isBefore(i)&&(!t||!i.isBefore(t)))}))}function k(e){const t=e.toLowerCase();return"default"===t||"system"===t?t:function(e){return"default"===e||"system"===e?(0,f.KQ)({timeZone:e}).timeZone():e}(e)}function A(e){return`UTC ${(0,f.KQ)({timeZone:e}).format("Z")}`}function N({value:e,timeZone:t,alwaysShowAsAbsolute:i,format:s="L",presets:n}){var r,o,a,l,c,h;if(!e)return"";const d="default"===t?"":` (${A(t)})`;let u="";e.start&&(u="relative"!==e.start.type||i?null!==(o=null===(r=(0,f.bQ)(e.start.value,{timeZone:t}))||void 0===r?void 0:r.format(s))&&void 0!==o?o:"":e.start.value);let g="";if(e.end&&(g="relative"!==e.end.type||i?null!==(l=null===(a=(0,f.bQ)(e.end.value,{timeZone:t,roundUp:!0}))||void 0===a?void 0:a.format(s))&&void 0!==l?l:"":e.end.value),!i&&"relative"===(null===(c=e.start)||void 0===c?void 0:c.type)&&"relative"===(null===(h=e.end)||void 0===h?void 0:h.type))return`${function(e,t,i=w){const s=e.replace(/\s+/g,""),n=t.replace(/\s+/g,"");for(const r of i)if(r.from===s&&r.to===n)return r.title;if("now"===t){const e=L.exec(s);if(e){const[,t,i]=e;if(["s","m","h","d","w","M","y"].includes(i)){const e=1===Number(t)?R[i]:T[i];return b(e,{count:t})}}}return s+" \u2014 "+n}(e.start.value,e.end.value,n)}`;return`${u} \u2014 ${g}${d}`}const I=JSON.parse('{"Range date picker":"Range date picker"}'),O=JSON.parse('{"Range date picker":"\u0412\u044b\u0431\u043e\u0440 \u0434\u0438\u0430\u043f\u0430\u0437\u043e\u043d\u0430 \u0434\u0430\u0442"}'),D=(0,_.N)({en:I,ru:O},`${l}relative-range-date-picker-control`),M=c("relative-range-date-picker-control"),P=n.forwardRef((({props:e,state:t,open:i,isMobile:r,onClick:o,onKeyDown:a,onFocus:l,onClickCalendar:c,onUpdate:h},f)=>{var _;const{alwaysShowAsAbsolute:v,presetTabs:C,getRangeTitle:b}=e,E=e.format||"L",S=n.useMemo((()=>"function"===typeof b?b(t.value,t.timeZone):N({value:t.value,timeZone:t.timeZone,alwaysShowAsAbsolute:v,format:E,presets:null===C||void 0===C?void 0:C.flatMap((({presets:e})=>e))})),[v,E,b,C,t.timeZone,t.value]),y=e.validationState||(t.isInvalid?"invalid":void 0),w=null!==(_=e.errorMessage)&&void 0!==_?_:t.errors.join("\n"),L={id:e.id,role:"combobox","aria-haspopup":"dialog","aria-expanded":i,"aria-label":e["aria-label"],"aria-labelledby":e["aria-labelledby"],"aria-describedby":e["aria-describedby"],"aria-details":e["aria-details"],disabled:e.disabled,readOnly:e.readOnly,onClick:c,onKeyDown:a};return e.renderControl?e.renderControl({ref:f,value:t.value,title:S,validationState:y,errorMessage:w,open:i,triggerProps:L}):(0,s.jsxs)(n.Fragment,{children:[(0,s.jsx)(u.k,{id:e.id,autoFocus:e.autoFocus,controlRef:f,value:S,placeholder:e.placeholder,onUpdate:h,controlProps:Object.assign(Object.assign({className:M("input",{mobile:r})},L),{disabled:r,onClick:o}),onKeyDown:a,onFocus:l,validationState:y,errorMessage:w,errorPlacement:e.errorPlacement,pin:e.pin,size:e.size,label:e.label,hasClear:e.hasClear,disabled:e.disabled,endContent:(0,s.jsx)(g.$,{view:"flat-secondary",size:m(e.size),disabled:e.disabled,extraProps:{"aria-haspopup":"dialog","aria-expanded":i,"aria-label":D("Range date picker")},onClick:c,children:(0,s.jsx)(p.I,{data:d})})}),r?(0,s.jsx)("button",{className:M("mobile-trigger",{"has-clear":Boolean(e.hasClear&&t.value),"has-errors":t.isInvalid&&"inside"===e.errorPlacement,size:e.size}),onClick:o}):null]})}));P.displayName="Control";var F=i(12640),U=i(39238);const H=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("g",{clipPath:"url(#a)"},n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M4.312 4.29a.764.764 0 0 1 1.103-.62.75.75 0 1 0 .67-1.34 2.264 2.264 0 0 0-3.268 1.836L2.706 5.5H1.75a.75.75 0 0 0 0 1.5h.83l-.392 4.71a.764.764 0 0 1-1.103.62.75.75 0 0 0-.67 1.34 2.264 2.264 0 0 0 3.268-1.836L4.086 7H5.25a.75.75 0 1 0 0-1.5H4.21zm6.014 2.23a.75.75 0 0 0-1.152.96l.85 1.02-.85 1.02a.75.75 0 0 0 1.152.96L11 9.672l.674.808a.75.75 0 0 0 1.152-.96l-.85-1.02.85-1.02a.75.75 0 0 0-1.152-.96L11 7.328zM8.02 4.55a.75.75 0 0 1 .43.969l-.145.378a7.25 7.25 0 0 0 0 5.205l.145.378a.75.75 0 0 1-1.4.539l-.145-.378a8.75 8.75 0 0 1 0-6.282l.145-.378a.75.75 0 0 1 .97-.431m5.961 0a.75.75 0 0 1 .97.43l.145.379a8.75 8.75 0 0 1 0 6.282l-.146.378a.75.75 0 1 1-1.4-.538l.146-.379a7.25 7.25 0 0 0 0-5.205l-.146-.378a.75.75 0 0 1 .431-.97",clipRule:"evenodd"})),n.createElement("defs",null,n.createElement("clipPath",{id:"a"},n.createElement("path",{fill:"currentColor",d:"M0 0h16v16H0z"})))),B=e=>n.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),n.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.5 8a5.5 5.5 0 1 1-11 0 5.5 5.5 0 0 1 11 0M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0M8.75 4.5a.75.75 0 0 0-1.5 0V8a.75.75 0 0 0 .3.6l2 1.5a.75.75 0 1 0 .9-1.2l-1.7-1.275z",clipRule:"evenodd"}));var W=i(32084),V=i(9187),z=i(38602),G=i(33705);function j({placeholderValue:e,timeZone:t}){return null!==e&&void 0!==e?e:(0,f.KQ)({timeZone:t}).set("hour",0).set("minute",0).set("second",0)}function K(e,t,i){return t&&e.isBefore(t)?t:i&&i.isBefore(e)?i:e}function Y(e,t){return e.set("hours",t.hour()).set("minutes",t.minute()).set("seconds",t.second())}function q(e,t,i){return(0,f.KQ)({input:e,timeZone:i}).format(t)}function $(e,t){const i=n.useRef(null),s=t.isCellFocused(e);n.useEffect((()=>{var e;s&&(null===(e=i.current)||void 0===e||e.focus({preventScroll:!0}))}),[s]);const r=t.focusedDate.isSame(e,t.mode)?0:-1,o=t.isCellDisabled(e),a=t.isSelected(e),l="highlightedRange"in t&&t.highlightedRange,c=Boolean(l&&a),h=a&&l&&e.isSame(l.start,t.mode),d=a&&l&&e.isSame(l.end,t.mode),u="days"===t.mode&&!t.focusedDate.isSame(e,"month"),g=t.isCellUnavailable(e),p=!o&&!g,m=t.isCurrent(e),f=t.isWeekend(e),_=function(e,t){switch(t.mode){case"days":return`${q(e,"dddd",t.timeZone)}, ${q(e,"LL",t.timeZone)}`;case"months":return`${q(e,"MMMM YYYY",t.timeZone)}`;case"quarters":return`${q(e,"[Q]Q YYYY",t.timeZone)}`;case"years":return`${q(e,"YYYY",t.timeZone)}`;default:return""}}(e,t),v={role:"gridcell","aria-selected":a?"true":void 0,"aria-disabled":o?"true":void 0},C={ref:i,role:"button",tabIndex:o?void 0:r,"aria-disabled":p?void 0:"true","aria-label":_,onClick:p?()=>{t.setFocusedDate(e),t.selectDate(e)}:void 0,onPointerEnter(){if("highlightDate"in t&&p)if(u){const i=e.isBefore(t.focusedDate)?t.focusedDate.startOf("month"):t.focusedDate.endOf("month").startOf("date");t.highlightDate(i)}else t.highlightDate(e)}};let b=q(e,"D",t.timeZone);return"months"===t.mode?b=q(e,"MMM",t.timeZone):"quarters"===t.mode?b=q(e,"[Q]Q",t.timeZone):"years"===t.mode&&(b=q(e,"YYYY",t.timeZone)),{cellProps:v,buttonProps:C,formattedDate:b,isDisabled:o,isSelected:a,isRangeSelection:c,isSelectionStart:h,isSelectionEnd:d,isOutsideCurrentRange:u,isUnavailable:g,isCurrent:m,isWeekend:f}}const Q=JSON.parse('{"Previous":"Previous","Next":"Next","Switch to months view":"Switch to months view","Switch to quarters view":"Switch to quarters view","Switch to years view":"Switch to years view"}'),X=JSON.parse('{"Previous":"\u041d\u0430\u0437\u0430\u0434","Next":"\u0412\u043f\u0435\u0440\u0451\u0434","Switch to months view":"\u041f\u0435\u0440\u0435\u043a\u043b\u044e\u0447\u0438\u0442\u044c\u0441\u044f \u043d\u0430 \u043f\u0440\u043e\u0441\u043c\u043e\u0442\u0440 \u043f\u043e \u043c\u0435\u0441\u044f\u0446\u0430\u043c","Switch to quarters view":"\u041f\u0435\u0440\u0435\u043a\u043b\u044e\u0447\u0438\u0442\u044c\u0441\u044f \u043d\u0430 \u043f\u0440\u043e\u0441\u043c\u043e\u0442\u0440 \u043f\u043e \u043a\u0432\u0430\u0440\u0442\u0430\u043b\u0430\u043c","Switch to years view":"\u041f\u0435\u0440\u0435\u043a\u043b\u044e\u0447\u0438\u0442\u044c\u0441\u044f \u043d\u0430 \u043f\u0440\u043e\u0441\u043c\u043e\u0442\u0440 \u043f\u043e \u0433\u043e\u0434\u0430\u043c"}'),Z=(0,_.N)({en:Q,ru:X},`${l}calendar`),J="yc-button_disabled g-button_disabled";function ee(e,t){const i=t.indexOf(e)+1;if(i===t.length)return;return{days:"",months:Z("Switch to months view"),quarters:Z("Switch to quarters view"),years:Z("Switch to years view")}[t[i]]}const te=["days","months","quarters","years"],ie=c("calendar"),se=n.forwardRef((function(e,t){const{state:i}=e,{calendarProps:r,modeButtonProps:o,nextButtonProps:l,previousButtonProps:c}=function(e,t){const i="years"===t.mode||"quarters"===t.mode?`${t.startDate.year()} \u2014 ${t.endDate.year()}`:q(t.focusedDate,"days"===t.mode?"MMMM YYYY":"YYYY",t.timeZone),{focusWithinProps:s}=(0,a.R)({onFocusWithin:e.onFocus,onBlurWithin:e.onBlur}),r=Object.assign({role:"group",id:e.id,"aria-label":[e["aria-label"],i].filter(Boolean).join(", "),"aria-labelledby":e["aria-labelledby"]||void 0,"aria-describedby":e["aria-describedby"]||void 0,"aria-details":e["aria-details"]||void 0,"aria-disabled":t.disabled||void 0},s),o=t.availableModes.indexOf(t.mode),l=o+1===t.availableModes.length,c=o+2===t.availableModes.length,h=t.disabled||l,d={disabled:t.disabled,className:h?J:void 0,onClick:h?void 0:()=>{t.zoomOut(),c&&t.setFocused(!0)},extraProps:{"aria-disabled":h?"true":void 0,"aria-description":ee(t.mode,t.availableModes),"aria-live":"polite"},children:i},u=n.useRef(!1),g=t.disabled||t.isPreviousPageInvalid();n.useLayoutEffect((()=>{g&&u.current&&(u.current=!1,t.setFocused(!0))}));const p={disabled:t.disabled,className:g?J:void 0,onClick:g?void 0:()=>{t.focusPreviousPage()},onFocus:g?void 0:()=>{u.current=!0},onBlur:g?void 0:()=>{u.current=!1},extraProps:{"aria-label":Z("Previous"),"aria-disabled":g?"true":void 0}},m=n.useRef(!1),f=t.disabled||t.isNextPageInvalid();return n.useLayoutEffect((()=>{f&&m.current&&(m.current=!1,t.setFocused(!0))})),{calendarProps:r,modeButtonProps:d,nextButtonProps:{disabled:t.disabled,className:f?J:void 0,onClick:f?void 0:()=>{t.focusNextPage()},onFocus:f?void 0:()=>{m.current=!0},onBlur:f?void 0:()=>{m.current=!1},extraProps:{"aria-label":Z("Next"),"aria-disabled":g?"true":void 0}},previousButtonProps:p}}(e,i);return n.useImperativeHandle(t,(()=>({focus(){i.setFocused(!0)}}))),(0,s.jsxs)("div",Object.assign({},r,{className:ie({size:e.size}),children:[(0,s.jsxs)("div",{className:ie("header"),children:[(0,s.jsx)(g.$,Object.assign({},o,{view:"flat",size:e.size,children:i.availableModes.indexOf(i.mode)+1===i.availableModes.length?(0,s.jsx)("span",{className:ie("mode-label",ie("years-label")),children:o.children},"label"):[(0,s.jsx)("span",{className:ie("mode-label"),children:o.children},"label"),(0,s.jsx)(g.$.Icon,{children:(0,s.jsx)(G.I,{direction:"bottom"})},"icon")]})),(0,s.jsxs)("div",{className:ie("controls"),children:[(0,s.jsx)(g.$,Object.assign({},c,{view:"flat",size:e.size,children:(0,s.jsx)(g.$.Icon,{children:(0,s.jsx)(V.A,{className:ie("control-icon")})})})),(0,s.jsx)(g.$,Object.assign({},l,{view:"flat",size:e.size,children:(0,s.jsx)(g.$.Icon,{children:(0,s.jsx)(z.A,{className:ie("control-icon")})})}))]})]}),(0,s.jsx)(ne,{state:i})]}))}));function ne({state:e}){const[t,i]=n.useState((()=>Object.assign(Object.assign({},e),{isFocused:!1}))),r=e.mode!==t.mode,o=!e.startDate.isSame(t.startDate,"days");let l;r?l=te.indexOf(t.mode)>te.indexOf(e.mode)?"zoom-out":"zoom-in":o&&(l=e.startDate.isBefore(t.startDate)?"forward":"backward");const{gridProps:c}=function(e){const{focusWithinProps:t}=(0,a.R)({onFocusWithinChange:t=>{e.setFocused(t)}});return{gridProps:Object.assign(Object.assign({role:"grid","aria-label":"years"===e.mode||"quarters"===e.mode?`${e.startDate.year()} \u2014 ${e.endDate.year()}`:q(e.focusedDate,"days"===e.mode?"MMMM YYYY":"YYYY",e.timeZone),"aria-disabled":e.disabled?"true":void 0,"aria-readonly":e.readOnly?"true":void 0},t),{onKeyDown:t=>{"ArrowRight"===t.key?(t.preventDefault(),e.focusNextCell()):"ArrowLeft"===t.key?(t.preventDefault(),e.focusPreviousCell()):"ArrowDown"===t.key?(t.preventDefault(),e.focusNextRow()):"ArrowUp"===t.key?(t.preventDefault(),e.focusPreviousRow()):"PageDown"===t.key?(t.preventDefault(),e.focusNextPage(t.shiftKey)):"PageUp"===t.key?(t.preventDefault(),e.focusPreviousPage(t.shiftKey)):"End"===t.key?(t.preventDefault(),e.focusSectionEnd()):"Home"===t.key?(t.preventDefault(),e.focusSectionStart()):"Minus"===t.code?(t.preventDefault(),e.zoomOut()):"Equal"===t.code?(t.preventDefault(),e.zoomIn()):"Enter"!==t.key&&" "!==t.key||(t.preventDefault(),e.selectDate(e.focusedDate))}})}}(e);return(0,s.jsxs)("div",Object.assign({className:ie("grid")},c,{children:[l&&(0,s.jsx)(re,{className:ie("previous-state"),state:t,animation:l}),(0,s.jsx)(re,{className:ie("current-state"),state:e,animation:l,onAnimationEnd:()=>{i(Object.assign(Object.assign({},e),{isFocused:!1}))}},"current")]}))}function re({className:e,state:t,animation:i,onAnimationEnd:n}){return(0,s.jsxs)("div",{className:ie("content",{animation:i},e),onAnimationEnd:n,role:"presentation",children:["days"===t.mode&&(0,s.jsx)(oe,{state:t}),(0,s.jsx)(ae,{state:t})]})}function oe({state:e}){const t=function(e){const t=[],i=(0,f.KQ)({timeZone:e.timeZone}).startOf("week");for(let s=0;s<7;s++){const e=i.add({days:s});t.push(e)}return t}(e);return(0,s.jsx)("div",{className:ie("grid-row"),role:"row",children:t.map((t=>(0,s.jsx)("div",{className:ie("weekday",{weekend:e.isWeekend(t)}),role:"columnheader","aria-label":q(t,"dddd",e.timeZone),children:q(t,"dd",e.timeZone)},t.day())))})}function ae({state:e}){const t="days"===e.mode?6:4,i="days"===e.mode?7:3+("quarters"===e.mode?1:0),n=function(e){const t=[],i=(0,f.KQ)({input:e.startDate,timeZone:e.timeZone});if("days"===e.mode){const e=i.startOf("week");for(let i=0;i<42;i++)t.push(e.add({days:i}))}else if("quarters"===e.mode)for(let s=0;s<16;s++)t.push(i.add(s,"quarters"));else for(let s=0;s<12;s++)t.push(i.add({[e.mode]:s}));return t}(e);return(0,s.jsx)("div",{className:ie("grid-rowgroup",{mode:e.mode}),role:"rowgroup",children:[...new Array(t).keys()].map((t=>(0,s.jsxs)("div",{className:ie("grid-row"),role:"row",children:["quarters"===e.mode?(0,s.jsx)("span",{role:"rowheader",className:ie("grid-rowgroup-header"),children:q(n[t*i],"YYYY",e.timeZone)}):null,n.slice(t*i,(t+1)*i).map((t=>(0,s.jsx)(le,{date:t,state:e},t.unix())))]},t)))})}function le({date:e,state:t}){const{cellProps:i,buttonProps:n,formattedDate:r,isDisabled:o,isSelected:a,isRangeSelection:l,isSelectionStart:c,isSelectionEnd:h,isOutsideCurrentRange:d,isUnavailable:u,isCurrent:g,isWeekend:p}=$(e,t);return(0,s.jsx)("div",Object.assign({},i,{children:(0,s.jsx)("div",Object.assign({},n,{className:ie("button",{disabled:o,selected:a,"range-selection":l,"selection-start":c,"selection-end":h,"out-of-boundary":d,unavailable:u,current:g,weekend:p}),children:r}))}))}function ce(e){const t=e?e.timeZone():"default",[i,s]=n.useState(t);e&&t!==i&&s(t);return e?t:i}const he={days:!0,months:!0,quarters:!1,years:!0};function de(e,t){if("days"===t)return e.startOf("month");if("months"===t)return e.startOf("year");if("quarters"===t){const t=4*Math.floor(e.year()/4);return e.startOf("year").set("year",t)}const i=12*Math.floor(e.year()/12);return e.startOf("year").set("year",i)}function ue(e,t){if("days"===t)return e.endOf("month").startOf("day");if("months"===t)return e.endOf("year").startOf("month");const i=de(e,t);return"quarters"===t?i.add(15,"quarters"):i.add({[t]:11})}function ge(e,t,i,s="days"){return!K(e,t,i).isSame(e,s)}const pe=n.forwardRef((function(e,t){const i=function(e){var t,i,s;const{disabled:r,readOnly:a,modes:l=he}=e,[c,h]=(0,o.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),d=te.filter((e=>l[e])),u=d[0]||"days",[g,p]=(0,o.P)(e.mode,null!==(i=e.defaultMode)&&void 0!==i?i:u,e.onUpdateMode),m=g&&d.includes(g)?g:u,_=ce(e.value||e.defaultValue||e.focusedValue||e.defaultFocusedValue),v=e.timeZone||_,C=n.useMemo((()=>e.minValue?e.minValue.timeZone(v):void 0),[v,e.minValue]),b=n.useMemo((()=>e.maxValue?e.maxValue.timeZone(v):void 0),[v,e.maxValue]),E=n.useMemo((()=>e.focusedValue?K(e.focusedValue.timeZone(v),C,b):e.focusedValue),[e.focusedValue,C,b,v]),S=n.useMemo((()=>{var t;return K((null===(t=e.defaultFocusedValue?e.defaultFocusedValue:c)||void 0===t?void 0:t.timeZone(v))||j({timeZone:v}).startOf(u),C,b)}),[b,C,e.defaultFocusedValue,v,c,u]),[y,w]=(0,o.P)(E,S,(t=>{var i;null===(i=e.onFocusUpdate)||void 0===i||i.call(e,t.timeZone(_))})),L=null!==(s=null===y||void 0===y?void 0:y.timeZone(v))&&void 0!==s?s:K(j({timeZone:v}),C,b);function R(e){w(K(e.startOf(m),C,b))}ge(L,C,b)&&w(K(L,C,b));const[T,x]=n.useState(e.autoFocus||!1),k=de(L,m),A=ue(L,m);return{disabled:r,readOnly:a,value:c,setValue(e){if(!r&&!a){let t=K(e,C,b);if(this.isCellUnavailable(t))return;c&&(t=Y(t,c.timeZone(v))),h(t.timeZone(_))}},timeZone:v,selectDate(e,t=!1){r||(a||!t&&this.mode!==u?this.zoomIn():(this.setValue(e.startOf(u)),t&&m!==u&&p(u)))},minValue:C,maxValue:b,focusedDate:L,startDate:k,endDate:A,setFocusedDate(e){R(e),x(!0)},focusNextCell(){R(L.add(1,this.mode))},focusPreviousCell(){R(L.subtract(1,this.mode))},focusNextRow(){"days"===this.mode?R(L.add(1,"week")):"quarters"===this.mode?R(L.add(1,"years")):R(L.add(3,this.mode))},focusPreviousRow(){"days"===this.mode?R(L.subtract(1,"week")):"quarters"===this.mode?R(L.subtract(1,"years")):R(L.subtract(3,this.mode))},focusNextPage(e){"days"===this.mode?R(L.add({months:e?12:1})):"quarters"===this.mode?R(L.add(4,"years")):R(L.add(12,this.mode))},focusPreviousPage(e){"days"===this.mode?R(L.subtract({months:e?12:1})):"quarters"===this.mode?R(L.subtract(4,"years")):R(L.subtract(12,this.mode))},focusSectionStart(){R(de(L,this.mode))},focusSectionEnd(){R(ue(L,this.mode))},zoomIn(){const e=d[d.indexOf(this.mode)-1];e&&this.setMode(e)},zoomOut(){const e=d[d.indexOf(this.mode)+1];e&&this.setMode(e)},selectFocusedDate(){this.selectDate(L,!0)},isFocused:T,setFocused:x,isInvalid(e){return ge(e,this.minValue,this.maxValue,this.mode)},isPreviousPageInvalid(){const e=this.startDate.subtract(1,"day");return this.isInvalid(e)},isNextPageInvalid(){const e=this.endDate.endOf(this.mode).add(1,"day");return this.isInvalid(e)},isSelected(e){return Boolean(c&&e.isSame(c.timeZone(v),m)&&!this.isCellDisabled(e))},isCellUnavailable(t){return this.mode===u&&Boolean(e.isDateUnavailable&&e.isDateUnavailable(t))},isCellFocused(e){return this.isFocused&&L&&e.isSame(L,m)},isCellDisabled(e){return this.disabled||this.isInvalid(e)},isWeekend(t){return"days"===this.mode&&("function"===typeof e.isWeekend?e.isWeekend(t):function(e){return[0,6].includes(e.day())}(t))},isCurrent(e){return(0,f.KQ)({timeZone:v}).isSame(e,this.mode)},mode:m,setMode:p,availableModes:d}}(e);return(0,s.jsx)(se,Object.assign({ref:t},e,{state:i}))}));var me=i(27145);const fe=JSON.parse('{"year_placeholder":"Y","month_placeholder":"M","weekday_placeholder":"E","day_placeholder":"D","hour_placeholder":"h","minute_placeholder":"m","second_placeholder":"s","dayPeriod_placeholder":"aa"}'),_e=JSON.parse('{"year_placeholder":"\u0413","month_placeholder":"\u041c","weekday_placeholder":"\u0414\u041d","day_placeholder":"\u0414","hour_placeholder":"\u0447","minute_placeholder":"\u043c","second_placeholder":"\u0441","dayPeriod_placeholder":"(\u0434|\u043f)\u043f"}'),ve=(0,_.N)({en:fe,ru:_e},`${l}date-field`),Ce={year:!0,month:!0,day:!0,hour:!0,minute:!0,second:!0,dayPeriod:!0,weekday:!0},be={start:"[",end:"]"},Ee={YY:"year",YYYY:"year",M:"month",MM:"month",MMM:{sectionType:"month",contentType:"letter"},MMMM:{sectionType:"month",contentType:"letter"},D:"day",DD:"day",Do:"day",d:"weekday",dd:{sectionType:"weekday",contentType:"letter"},ddd:{sectionType:"weekday",contentType:"letter"},dddd:{sectionType:"weekday",contentType:"letter"},A:{sectionType:"dayPeriod",contentType:"letter"},a:{sectionType:"dayPeriod",contentType:"letter"},H:"hour",HH:"hour",h:"hour",hh:"hour",m:"minute",mm:"minute",s:"second",ss:"second",z:{sectionType:"timeZoneName",contentType:"letter"},zzz:{sectionType:"timeZoneName",contentType:"letter"},Z:{sectionType:"timeZoneName",contentType:"letter"},ZZ:{sectionType:"timeZoneName",contentType:"letter"}};function Se(e){return 4===(0,f.KQ)().format(e).length}function ye(e,t){const{type:i,format:s}=e;switch(i){case"year":{const e=Se(s);return{minValue:e?1:0,maxValue:e?9999:99}}case"month":return{minValue:0,maxValue:11};case"weekday":return{minValue:0,maxValue:6};case"day":return{minValue:1,maxValue:t?t.daysInMonth():31};case"hour":if(function(e){return"15"!==(0,f.KQ)().set("hour",15).format(e)}(s)){const e=t.hour()>=12;return{minValue:e?12:0,maxValue:e?23:11}}return{minValue:0,maxValue:23};case"minute":case"second":return{minValue:0,maxValue:59}}return{}}function we(e,t){const i=e.type;switch(i){case"year":return Se(e.format)?t.year():Number(t.format(e.format));case"month":case"hour":case"minute":case"second":return t[i]();case"day":return t.date();case"weekday":return t.day();case"dayPeriod":return t.hour()>=12?12:0}}const Le={weekday:"day",day:"date",dayPeriod:"hour"};function Re(e){if("literal"===e||"timeZoneName"===e||"unknown"===e)throw new Error(`${e} section does not have duration unit.`);return e in Le?Le[e]:e}function Te(e,t){switch(e.type){case"year":return ve("year_placeholder").repeat((0,f.KQ)().format(t).length);case"month":return ve("month_placeholder").repeat("letter"===e.contentType?4:2);case"day":return ve("day_placeholder").repeat(2);case"weekday":return ve("weekday_placeholder").repeat("letter"===e.contentType?4:2);case"hour":return ve("hour_placeholder").repeat(2);case"minute":return ve("minute_placeholder").repeat(2);case"second":return ve("second_placeholder").repeat(2);case"dayPeriod":return ve("dayPeriod_placeholder");default:return t}}function xe(e){const t=[],i=(0,f.cS)(e);let s="",n=!1,r=!1;for(let o=0;o1;case"day":return(0,f.KQ)().startOf("month").format(i).length>1;case"weekday":return(0,f.KQ)().startOf("week").format(i).length>1;case"hour":return(0,f.KQ)().set("hour",1).format(i).length>1;case"minute":return(0,f.KQ)().set("minute",1).format(i).length>1;case"second":return(0,f.KQ)().set("second",1).format(i).length>1;default:throw new Error("Invalid section type")}}(i.contentType,i.type,t);e.push(Object.assign(Object.assign({},i),{format:t,placeholder:Te(i,t),options:Ne(i,t),hasLeadingZeros:s}))}function Ae(e,t){t&&e.push({type:"literal",contentType:"letter",format:t,placeholder:t,hasLeadingZeros:!1})}function Ne(e,t){switch(e.type){case"month":{const i="letter"===e.contentType?t:"MMMM";let s=(0,f.KQ)().startOf("year");const n=[];for(let e=0;e<12;e++)n.push(s.format(i).toLocaleUpperCase()),s=s.add(1,"months");return n}case"dayPeriod":{const e=(0,f.KQ)().hour(0),i=e.hour(12);return[e.format(t).toLocaleUpperCase(),i.format(t).toLocaleUpperCase()]}case"weekday":{const i="letter"===e.contentType?t:"dddd";let s=(0,f.KQ)().day(0);const n=[];for(let e=0;e<7;e++)n.push(s.format(i).toLocaleUpperCase()),s=s.add(1,"day");return n}}}function Ie(e,t,i){let s=1;const n=[];let r=-1;for(let o=0;ot[e]))}function Ue(e,t){const i=n.useRef(null),[,s]=n.useState({});function r(t){e.setSelectedSections(t),s({})}function o(){var t,n;e.focusSectionInPosition(null!==(n=null===(t=i.current)||void 0===t?void 0:t.selectionStart)&&void 0!==n?n:0),s({})}n.useLayoutEffect((()=>{const t=i.current;if(!t)return;if(null===e.selectedSectionIndexes)return void(t.scrollLeft&&(t.scrollLeft=0));const s=e.sections[e.selectedSectionIndexes.startIndex],n=e.sections[e.selectedSectionIndexes.endIndex];if(s&&n){const e=s.start,i=n.end;e===t.selectionStart&&i===t.selectionEnd||t.setSelectionRange(e,i)}}));const a=n.useMemo((()=>{if(!e.selectedSectionIndexes)return"text";const t=e.sections[e.selectedSectionIndexes.startIndex];return t&&"letter"!==t.contentType?"tel":"text"}),[e.selectedSectionIndexes,e.sections]);return{inputProps:{value:e.text,view:t.view,size:t.size,disabled:e.disabled,hasClear:!e.readOnly&&!e.isEmpty&&t.hasClear,placeholder:t.placeholder,id:t.id,label:t.label,startContent:t.startContent,endContent:t.endContent,pin:t.pin,autoFocus:t.autoFocus,controlRef:i,autoComplete:"off",type:"text",validationState:e.validationState,errorMessage:t.errorMessage,errorPlacement:t.errorPlacement,onUpdate(t){t||e.clearAll()},onFocus(s){var n;if(null===(n=t.onFocus)||void 0===n||n.call(t,s),null!==e.selectedSectionIndexes)return;const a=s.target,l=!i.current;setTimeout((()=>{a&&a===i.current&&(l?e.focusSectionInPosition(0):a.value.length&&Number(a.selectionEnd)-Number(a.selectionStart)===a.value.length?r("all"):o())}))},onBlur(e){var i;null===(i=t.onBlur)||void 0===i||i.call(t,e),r(-1)},onKeyDown(i){var s;null===(s=t.onKeyDown)||void 0===s||s.call(t,i),"ArrowLeft"===i.key?(i.preventDefault(),e.focusPreviousSection()):"ArrowRight"===i.key?(i.preventDefault(),e.focusNextSection()):"Home"===i.key?(i.preventDefault(),e.decrementToMin()):"End"===i.key?(i.preventDefault(),e.incrementToMax()):"ArrowUp"!==i.key||i.altKey?"ArrowDown"!==i.key||i.altKey?"PageUp"===i.key?(i.preventDefault(),e.incrementPage()):"PageDown"===i.key?(i.preventDefault(),e.decrementPage()):"Backspace"===i.key||"Delete"===i.key?(i.preventDefault(),e.clearSection()):"a"===i.key&&(i.ctrlKey||i.metaKey)&&(i.preventDefault(),r("all")):(i.preventDefault(),e.decrement()):(i.preventDefault(),e.increment())},onKeyUp:t.onKeyUp,controlProps:{"aria-label":t["aria-label"]||void 0,"aria-labelledby":t["aria-labelledby"]||void 0,"aria-describedby":t["aria-describedby"]||void 0,"aria-details":t["aria-details"]||void 0,"aria-disabled":e.disabled||void 0,readOnly:e.readOnly,inputMode:a,onClick(){o()},onMouseUp(e){e.preventDefault()},onBeforeInput(t){t.preventDefault();const i=t.data;void 0!==i&&null!==i&&e.onInput(i)},onPaste(t){if(t.preventDefault(),e.readOnly)return;const i=t.clipboardData.getData("text").replace(/[\u2066\u2067\u2068\u2069]/g,"");if(e.selectedSectionIndexes&&e.selectedSectionIndexes.startIndex===e.selectedSectionIndexes.endIndex){const t=e.sections[e.selectedSectionIndexes.startIndex],s=/^\d+$/.test(i),n=/^[a-zA-Z]+$/.test(i);if(Boolean(t&&("digit"===t.contentType&&s||"letter"===t.contentType&&n)))return void e.onInput(i);if(s||n)return}e.setValueFromString(i)}}}}}const He={year:5,month:2,weekday:3,day:7,hour:2,minute:15,second:15};function Be(e){var t,i;const[s,r]=(0,o.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),a=ce(e.value||e.defaultValue||e.placeholderValue),l=e.timeZone||a,c=e=>{r(e?e.timeZone(a):e)},[h,d]=n.useState((()=>j({placeholderValue:e.placeholderValue,timeZone:l}))),u=e.format||"L",g=function(e){const t=e,[i,s]=n.useState((()=>xe(t))),[r,o]=n.useState(t);return t!==r&&(o(t),s(xe(t))),i}(u),p=n.useMemo((()=>g.filter((e=>Ce[e.type])).reduce(((e,t)=>Object.assign(Object.assign({},e),{[t.type]:!0})),{})),[g]),m=n.useState((()=>s?Object.assign({},p):{}));let _=m[0];const v=m[1];s&&!Fe(p,_)&&v(Object.assign({},p)),!s&&Object.keys(p).length>0&&Fe(p,_)&&Object.keys(_).length===Object.keys(p).length&&(_={},v(_),d(j({placeholderValue:e.placeholderValue,timeZone:l})));const C=s&&s.isValid()&&Fe(p,_)?s.timeZone(l):h.timeZone(l),b=function(e,t,i){const[s,r]=n.useState((()=>({value:t,sections:e,validSegments:i,editableSections:Ie(e,t,i)})));e===s.sections&&i===s.validSegments&&t.isSame(s.value)&&t.timeZone()===s.value.timeZone()||r({value:t,sections:e,validSegments:i,editableSections:Ie(e,t,i)});return s}(g,C,_),[E,S]=n.useState(-1),y=n.useMemo((()=>{if(-1===E)return null;if("all"===E)return{startIndex:0,endIndex:b.editableSections.length-1};if("number"===typeof E)return{startIndex:E,endIndex:E};if("string"===typeof E){const e=b.editableSections.findIndex((e=>e.type===E));return{startIndex:e,endIndex:e}}return E}),[E,b.editableSections]);function w(t){e.disabled||e.readOnly||(Fe(p,_)?s&&t.isSame(s)||c(t):(s&&c(null),d(t)))}function L(e){_[e]=!0,_.day&&_.month&&_.year&&p.weekday&&(_.weekday=!0),_.hour&&p.dayPeriod&&(_.dayPeriod=!0),v(Object.assign({},_))}const R=e.validationState||(function(e,t,i){return!!e&&(!(!t||!e.isBefore(t))||!(!i||!i.isBefore(e)))}(s,e.minValue,e.maxValue)?"invalid":void 0)||(s&&(null===(i=e.isDateUnavailable)||void 0===i?void 0:i.call(e,s))?"invalid":void 0);return function(e){const{value:t,validationState:i,displayValue:s,editableSections:r,selectedSectionIndexes:o,selectedSections:a,isEmpty:l,flushAllValidSections:c,flushValidSection:h,setSelectedSections:d,setValue:u,setDate:g,adjustSection:p,setSection:m,getSectionValue:f,setSectionValue:_,createPlaceholder:v,setValueFromString:C}=e,b=n.useRef(""),{hasDate:E,hasTime:S}=n.useMemo((()=>{let e=!1,t=!1;for(const i of r)t||(t=["hour","minute","second"].includes(i.type)),e||(e=["day","month","year"].includes(i.type));return{hasTime:t,hasDate:e}}),[r]);return{value:t,isEmpty:l,displayValue:s,setValue:u,setDate:g,text:(y=r,"\u2066"+y.map((e=>e.textValue)).join("")+"\u2069"),readOnly:e.readOnly,disabled:e.disabled,sections:r,hasDate:E,hasTime:S,selectedSectionIndexes:o,validationState:i,setSelectedSections(e){b.current="",d(e)},focusSectionInPosition(e){const t=this.sections.findIndex((t=>t.end>=e)),i=-1===t?0:t,s=this.sections[i];s&&this.setSelectedSections(Ce[s.type]?i:s.nextEditableSection)},focusNextSection(){var e,t;const i="all"===a?0:a,s=null!==(t=null===(e=this.sections[i])||void 0===e?void 0:e.nextEditableSection)&&void 0!==t?t:-1;-1!==s&&this.setSelectedSections(s)},focusPreviousSection(){var e,t;const i="all"===a?0:a,s=null!==(t=null===(e=this.sections[i])||void 0===e?void 0:e.previousEditableSection)&&void 0!==t?t:-1;-1!==s&&this.setSelectedSections(s)},focusFirstSection(){var e,t;const i=null!==(t=null===(e=this.sections[0])||void 0===e?void 0:e.previousEditableSection)&&void 0!==t?t:-1;-1!==i&&d(i)},focusLastSection(){var e,t;const i=null!==(t=null===(e=this.sections[this.sections.length-1])||void 0===e?void 0:e.nextEditableSection)&&void 0!==t?t:-1;-1!==i&&this.setSelectedSections(i)},increment(){if(this.readOnly||this.disabled)return;b.current="";const e=Me(this.sections,a);-1!==e&&p(e,1)},decrement(){if(this.readOnly||this.disabled)return;b.current="";const e=Me(this.sections,a);-1!==e&&p(e,-1)},incrementPage(){if(this.readOnly||this.disabled)return;b.current="";const e=Me(this.sections,a);-1!==e&&p(e,He[this.sections[e].type]||1)},decrementPage(){if(this.readOnly||this.disabled)return;b.current="";const e=Me(this.sections,a);-1!==e&&p(e,-(He[this.sections[e].type]||1))},incrementToMax(){if(this.readOnly||this.disabled)return;b.current="";const e=Me(this.sections,a);if(-1!==e){const t=this.sections[e];"number"===typeof t.maxValue&&m(e,t.maxValue)}},decrementToMin(){if(this.readOnly||this.disabled)return;b.current="";const e=Me(this.sections,a);if(-1!==e){const t=this.sections[e];"number"===typeof t.minValue&&m(e,t.minValue)}},clearSection(){if(this.readOnly||this.disabled)return;if(b.current="","all"===a)return void this.clearAll();const t=Me(this.sections,a);if(-1===t)return;h(t);const i=this.sections[t],s=j({placeholderValue:e.placeholderValue,timeZone:e.timeZone}).timeZone(e.timeZone),n=f(t);let r=n;if("dayPeriod"===i.type){const e=n.hour()>=12,t=s.hour()>=12;e&&!t?r=n.set("hour",n.hour()-12):!e&&t&&(r=n.set("hour",n.hour()+12))}else{const e=Re(i.type);r=n.set(e,s[e]())}_(t,r)},clearAll(){if(this.readOnly||this.disabled)return;b.current="",c(),null!==t&&g(null);const e=v();u(e)},onInput(e){if(this.readOnly||this.disabled)return;const t=Me(this.sections,a);if(-1===t)return;const i=this.sections[t];let s=b.current+e;const n=n=>{var r,o,a;let l="month"===i.type?n-1:n;const c=0===i.minValue;if("hour"!==i.type||12!==i.minValue&&11!==i.maxValue){if(l>(null!==(r=i.maxValue)&&void 0!==r?r:0)&&(l=Number(e)-("month"===i.type?1:0),s=e,l>(null!==(o=i.maxValue)&&void 0!==o?o:0)))return void(b.current="")}else n>12&&(l=Number(e)),12===i.minValue&&l>1&&(l+=12);const h=l>0||0===l&&c;h&&m(t,l),Number(n+"0")>(null!==(a=i.maxValue)&&void 0!==a?a:0)||s.length>=String(i.maxValue).length?(b.current="",h&&this.focusNextSection()):b.current=s},r=n=>{var r;const o=null!==(r=i.options)&&void 0!==r?r:[];let a=n.toLocaleUpperCase(),l=o.filter((e=>e.startsWith(a)));if(0===l.length&&(n!==e&&(a=e.toLocaleUpperCase(),l=o.filter((e=>e.startsWith(a)))),0===l.length))return void(b.current="");const c=l[0],h=o.indexOf(c);"dayPeriod"===i.type?m(t,1===h?12:0):m(t,h),l.length>1?b.current=s:(b.current="",this.focusNextSection())};switch(i.type){case"day":case"hour":case"minute":case"second":case"year":if(!Number.isInteger(Number(s)))return;n(Number(s));break;case"dayPeriod":r(s);break;case"weekday":case"month":Number.isInteger(Number(s))?n(Number(s)):r(s)}},setValueFromString:e=>(b.current="",C(e))};var y}({value:s,displayValue:C,placeholderValue:e.placeholderValue,timeZone:l,validationState:R,editableSections:b.editableSections,readOnly:e.readOnly,disabled:e.disabled,selectedSectionIndexes:y,selectedSections:E,isEmpty:0===Object.keys(_).length,flushAllValidSections:function(){_={},v({})},flushValidSection:function(e){const t=b.editableSections[e];t&&delete _[t.type],v(Object.assign({},_))},setSelectedSections:S,setValue:w,setDate:c,adjustSection:function(e,t){const i=b.editableSections[e];i&&(_[i.type]?w(function(e,t,i){var s;let n=null!==(s=e.value)&&void 0!==s?s:0;if("dayPeriod"===e.type)n=t.hour()+(t.hour()>=12?-12:12);else{n+=i;const t=e.minValue,s=e.maxValue;if("number"===typeof t&&"number"===typeof s){const e=s-t+1;n=(n-t+e)%e+t}}"year"!==e.type||Se(e.format)||(n=(0,f.KQ)({input:`${n}`.padStart(2,"0"),format:e.format}).year());const r=Re(e.type);return t.set(r,n)}(i,C,t)):(L(i.type),Object.keys(_).length>=Object.keys(p).length&&w(C)))},setSection:function(e,t){const i=b.editableSections[e];i&&(L(i.type),w(function(e,t,i){const s=e.type;switch(s){case"year":return t.set("year",Se(e.format)?i:(0,f.KQ)({input:`${i}`.padStart(2,"0"),format:e.format}).year());case"day":case"weekday":case"month":return t.set(Re(s),i);case"dayPeriod":{const e=t.hour(),s=e>=12;return i>=12===s?t:t.set("hour",s?e-12:e+12)}case"hour":{let s=i;if(12===e.minValue||11===e.maxValue){const e=t.hour()>=12;e||12!==s||(s=0),e&&s<12&&(s+=12)}return t.set("hour",s)}case"minute":case"second":return t.set(s,i)}return t}(i,C,t)))},getSectionValue:function(e){return C},setSectionValue:function(e,t){w(t)},createPlaceholder:function(){return j({placeholderValue:e.placeholderValue,timeZone:l}).timeZone(l)},setValueFromString:function(e){const t=function(e,t,i){let s=Pe({input:e,format:t,timeZone:i});s.isValid()&&i&&!function(e){return/z$/i.test(e)||/[+-]\d\d:\d\d$/.test(e)}(e)&&(s=Y(s,Pe({input:e,format:t})));return s}(e,u,l);return!!t.isValid()&&(c(t),!0)}})}const We=c("date-field");function Ve(e){var{className:t}=e,i=(0,me.Tt)(e,["className"]);const r=Be(i),{inputProps:o}=Ue(r,i),[l,c]=n.useState(!1),{focusWithinProps:d}=(0,a.R)({onFocusWithinChange(e){c(e)}});return(0,s.jsxs)("div",Object.assign({className:We(null,t),style:i.style},d,{children:[(0,s.jsx)(u.k,Object.assign({},o,{value:r.isEmpty&&!l&&i.placeholder?"":o.value})),(0,s.jsx)(h,{name:i.name,value:r.value,toStringValue:e=>{var t;return null!==(t=null===e||void 0===e?void 0:e.toISOString())&&void 0!==t?t:""},onReset:e=>{r.setDate(e)},disabled:r.disabled,form:i.form})]}))}const ze=c("mobile-calendar");function Ge({props:e,state:t}){var i,n;let r="date";return t.hasTime&&t.hasDate?r="datetime-local":t.hasTime&&(r="time"),(0,s.jsx)("input",{className:ze(),disabled:e.disabled,type:r,value:Ke(t.dateFieldState.value,r),id:e.id,min:Ke(null===(i=e.minValue)||void 0===i?void 0:i.timeZone(t.timeZone),r),max:Ke(null===(n=e.maxValue)||void 0===n?void 0:n.timeZone(t.timeZone),r),tabIndex:-1,onChange:i=>{var s,n;if(e.readOnly)return;const o=i.target.value;if(o){const i=(0,f.KQ)({input:o,format:je(r),timeZone:"system"}).timeZone(t.timeZone,!0);let a=t.hasDate?i:j({placeholderValue:null===(s=e.placeholderValue)||void 0===s?void 0:s.timeZone(t.timeZone),timeZone:t.timeZone});a=t.hasTime?Y(a,i):t.value?Y(a,t.value.timeZone(t.timeZone)):Y(a,j({placeholderValue:null===(n=e.placeholderValue)||void 0===n?void 0:n.timeZone(t.timeZone),timeZone:t.timeZone})),t.setValue(a)}else t.setValue(null)}})}function je(e){switch(e){case"time":return"HH:mm";case"datetime-local":return"YYYY-MM-DDTHH:mm";default:return"YYYY-MM-DD"}}function Ke(e,t){if(!e)return"";const i=je(t);return e.format(i)}const Ye=c("stub-button");function qe({size:e,icon:t}){return(0,s.jsx)("span",{className:Ye({size:e}),children:(0,s.jsx)("span",{className:Ye("icon"),children:(0,s.jsx)(p.I,{data:t})})})}function $e(...e){const t=Object.assign({},e[0]);for(let i=1;i=65&&e.charCodeAt(2)<=90?t[e]=Qe(i,n):t[e]="className"===e&&"string"===typeof i&&"string"===typeof n?i+" "+n:"controlProps"===e&&"object"===typeof i&&"object"===typeof n?$e(i,n):void 0===n?i:n}}return t}function Qe(...e){return(...t)=>{for(const i of e)"function"===typeof i&&i(...t)}}const Xe=JSON.parse('{"Calendar":"Calendar","Formula input mode":"Formula input mode"}'),Ze=JSON.parse('{"Calendar":"\u041a\u0430\u043b\u0435\u043d\u0434\u0430\u0440\u044c","Formula input mode":"\u0420\u0435\u0436\u0438\u043c \u0432\u0432\u043e\u0434\u0430 \u0444\u043e\u0440\u043c\u0443\u043b\u044b"}'),Je=(0,_.N)({en:Xe,ru:Ze},`${l}relative-date-picker`);function et(e,t){var{onFocus:i,onBlur:s}=t,r=(0,me.Tt)(t,["onFocus","onBlur"]);const{mode:l,setMode:c,datePickerState:h,relativeDateState:d}=e,[u,g]=n.useState("relative"===l?d.lastCorrectDate:h.dateFieldState.displayValue),[p,f]=n.useState(d.lastCorrectDate);p!==d.lastCorrectDate&&(f(d.lastCorrectDate),g(d.lastCorrectDate));const[_,v]=n.useState(h.dateFieldState.displayValue);h.dateFieldState.displayValue.isSame(_,"day")||(v(h.dateFieldState.displayValue),g(h.dateFieldState.displayValue));const{focusWithinProps:C}=(0,a.R)({onFocusWithin:i,onBlurWithin:s,onFocusWithinChange(t){t||e.setActive(!1)}}),[b,E]=(0,o.P)(void 0,!1,r.onOpenChange);!e.isActive&&b&&E(!1);const S={onFocus:()=>{e.isActive||(e.setActive(!0),E(!0))},errorMessage:r.errorMessage,errorPlacement:r.errorPlacement,controlProps:{onClick:()=>{e.disabled||b||(e.setActive(!0),E(!0))},role:"combobox","aria-expanded":b}},{inputProps:y}=Ue(h.dateFieldState,Object.assign(Object.assign({},r),{value:void 0,defaultValue:void 0,onUpdate:void 0})),{inputProps:w}=function(e,t){const[i,s]=n.useState(e.lastCorrectDate),[r,o]=n.useState(e.lastCorrectDate);return i!==e.lastCorrectDate&&(s(e.lastCorrectDate),o(e.lastCorrectDate)),{inputProps:{size:t.size,autoFocus:t.autoFocus,value:e.text,onUpdate:e.setText,disabled:e.disabled,hasClear:t.hasClear,validationState:e.validationState,errorMessage:t.errorMessage,errorPlacement:t.errorPlacement,label:t.label,id:t.id,startContent:t.startContent,endContent:t.endContent,pin:t.pin,view:t.view,placeholder:t.placeholder,onKeyDown:t.onKeyDown,onKeyUp:t.onKeyUp,onBlur:t.onBlur,onFocus:t.onFocus,controlProps:{"aria-label":t["aria-label"]||void 0,"aria-labelledby":t["aria-labelledby"]||void 0,"aria-describedby":t["aria-describedby"]||void 0,"aria-details":t["aria-details"]||void 0,"aria-disabled":e.disabled||void 0,readOnly:e.readOnly}},calendarProps:{size:"s"===t.size?"m":t.size,readOnly:!0,value:e.parsedDate,focusedValue:r,onFocusUpdate:o},timeInputProps:{size:t.size,readOnly:!0,value:e.lastCorrectDate,format:"LTS"}}}(d,Object.assign(Object.assign({},r),{value:void 0,defaultValue:void 0,onUpdate:void 0}));let L=r.validationState;L||(L="relative"===l?d.validationState:h.dateFieldState.validationState);const R=n.useRef(null),T=(0,W.N)(R,"relative"===l?w.controlRef:y.controlRef),x=n.useRef(null);function k(){setTimeout((()=>{var e;null===(e=x.current)||void 0===e||e.focus()}))}function A(){setTimeout((()=>{var e;null===(e=R.current)||void 0===e||e.focus({preventScroll:!0})}))}const N=n.useRef(null);return{groupProps:Object.assign(Object.assign({ref:N,tabIndex:-1,role:"group"},C),{onKeyDown:e=>{!e.altKey||"ArrowDown"!==e.key&&"ArrowUp"!==e.key||(e.preventDefault(),e.stopPropagation(),E(!0),k())}}),fieldProps:$e(S,"relative"===l?w:y,"absolute"===l&&h.dateFieldState.isEmpty&&!e.isActive&&r.placeholder?{value:""}:void 0,{controlRef:T,validationState:L}),modeSwitcherProps:{size:m(r.size),disabled:e.readOnly||e.disabled,view:"flat-secondary",style:{zIndex:2,marginInlineEnd:2},selected:"relative"===l,extraProps:{"aria-label":Je("Formula input mode")},onClick:()=>{if(c("relative"===l?"absolute":"relative"),"relative"===l){const e=h.value;e&&g(e)}else d.parsedDate&&g(d.parsedDate);A()}},calendarButtonProps:{size:m(r.size),disabled:e.disabled,extraProps:{"aria-label":Je("Calendar"),"aria-haspopup":"dialog","aria-expanded":b},view:"flat-secondary",onClick:()=>{e.setActive(!0),E(!b),b||k()}},popupProps:{open:b,onEscapeKeyDown:()=>{E(!1),A()},onOutsideClick:e=>{var t;e.target&&!(null===(t=N.current)||void 0===t?void 0:t.contains(e.target))&&E(!1)},onTransitionExited:()=>{g("relative"===l?d.lastCorrectDate:h.dateFieldState.displayValue)}},calendarProps:{ref:x,size:"s"===r.size?"m":r.size,readOnly:r.readOnly,value:e.selectedDate,onUpdate:t=>{h.setDateValue(t),e.datePickerState.hasTime||(E(!1),A())},focusedValue:u,onFocusUpdate:g,minValue:r.minValue,maxValue:r.maxValue},timeInputProps:{value:h.timeValue,onUpdate:h.setTimeValue,format:h.timeFormat,readOnly:e.readOnly,disabled:e.disabled,timeZone:r.timeZone,hasClear:r.hasClear,size:r.size}}}const tt=function({getPlaceholderTime:e,mergeDateTime:t,setTimezone:i,getDateTime:s,useDateFieldState:r}){return function(a){var l,c;const{disabled:h,readOnly:d}=a,[u,g]=(0,o.P)(a.open,null!==(l=a.defaultOpen)&&void 0!==l&&l,a.onOpenChange),p=g,[m,f]=(0,o.P)(a.value,null!==(c=a.defaultValue)&&void 0!==c?c:null,a.onUpdate),[_,v]=n.useState(null),[C,b]=n.useState(null),E=ce(s(a.value)||s(a.defaultValue)||a.placeholderValue),S=a.timeZone||E;let y=_,w=C;const L=a.format||"L",R=(e,s)=>{h||d||(f(i(t(e,s),E)),v(null),b(null))},T=r(Object.assign(Object.assign({},a),{value:m,onUpdate(e){e?R(e,e):f(null)},disabled:h,readOnly:d,validationState:a.validationState,minValue:a.minValue,maxValue:a.maxValue,isDateUnavailable:a.isDateUnavailable,format:L,placeholderValue:a.placeholderValue,timeZone:S})),x=n.useMemo((()=>{if(!T.hasTime)return;const e=[],t=T.sections.find((e=>"hour"===e.type));t&&e.push(t.format);const i=T.sections.find((e=>"minute"===e.type));i&&e.push(i.format);const s=T.sections.find((e=>"second"===e.type));s&&e.push(s.format);const n=T.sections.find((e=>"dayPeriod"===e.type));return e.join(":")+(n?` ${n.format}`:"")}),[T.hasTime,T.sections]);m&&(y=i(m,S),T.hasTime&&(w=i(m,S)));return T.hasTime&&!w&&(w=T.displayValue),{value:m,setValue(e){a.readOnly||a.disabled||f(e?i(e,E):null)},dateValue:y,timeValue:w,setDateValue:e=>{if(h||d)return;const t=!T.hasTime;T.hasTime?w||t?R(e,w||e):v(e):R(e,e),t&&p(!1,"ValueSelected")},setTimeValue:t=>{if(h||d)return;const i=null!==t&&void 0!==t?t:e(a.placeholderValue,S);y?R(y,i):b(i)},disabled:h,readOnly:d,format:L,hasDate:T.hasDate,hasTime:T.hasTime,timeFormat:x,timeZone:S,isOpen:u,setOpen(t,i){!t&&!m&&y&&T.hasTime&&R(y,w||e(a.placeholderValue,a.timeZone)),p(t,i)},dateFieldState:T}}}({getPlaceholderTime:function(e,t){return j({placeholderValue:e,timeZone:t})},mergeDateTime:Y,setTimezone:(e,t)=>e.timeZone(t),getDateTime:function(e){if(e)return"start"in e&&"end"in e?e.start:e},useDateFieldState:Be});function it(e){var t;const[i,s]=(0,o.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),[r,a]=n.useState("relative"===(null===i||void 0===i?void 0:i.type)?"relative":"absolute"),[l,c]=n.useState(i);i!==l&&(c(i),i&&i.type!==r&&a(i.type));const[h,d]=n.useState("absolute"===(null===i||void 0===i?void 0:i.type)?i.value:null);"absolute"===(null===i||void 0===i?void 0:i.type)&&i.value!==h&&d(i.value);const u=tt({value:h,onUpdate:e=>{d(e),"absolute"===(null===i||void 0===i?void 0:i.type)&&(null===e||void 0===e?void 0:e.isSame(i.value))||s(e?{type:"absolute",value:e}:null)},format:e.format,placeholderValue:e.placeholderValue,timeZone:e.timeZone,disabled:e.disabled,readOnly:e.readOnly,minValue:e.minValue,maxValue:e.maxValue}),[g,p]=n.useState("relative"===(null===i||void 0===i?void 0:i.type)?i.value:null);"relative"===(null===i||void 0===i?void 0:i.type)&&i.value!==g&&p(i.value);const m=function(e){var t;const[i,s]=(0,o.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null,e.onUpdate),[r,a]=n.useState(null!==i&&void 0!==i?i:"");i&&i!==r&&a(i);const l=n.useMemo((()=>{var t;return i&&null!==(t=(0,f.bQ)(i,{timeZone:e.timeZone,roundUp:e.roundUp}))&&void 0!==t?t:null}),[i,e.timeZone,e.roundUp]),[c,h]=n.useState(l);l&&l!==c&&h(l);const d=e.validationState||r&&!l?"invalid":void 0;return{value:i,setValue(t){e.disabled||e.readOnly||s(t)},text:r,setText:t=>{if(!e.disabled&&!e.readOnly)if(a(t),(0,f.eP)(t)){const e=(0,f.bQ)(t);e&&e.isValid()?s(t):s(null)}else s(null)},parsedDate:l,lastCorrectDate:c,validationState:d,disabled:e.disabled,readOnly:e.readOnly}}({value:g,onUpdate:e=>{p(e),"relative"===(null===i||void 0===i?void 0:i.type)&&e===i.value||s(e?{type:"relative",value:e}:null)},disabled:e.disabled,readOnly:e.readOnly,timeZone:u.timeZone,roundUp:e.roundUp});i||("absolute"===r&&h?d(null):"relative"===r&&g&&p(null));const _="relative"===r?m.parsedDate:u.dateFieldState.displayValue,[v,C]=n.useState(!1);return{value:i,setValue(t){e.readOnly||e.disabled||s(t)},disabled:e.disabled,readOnly:e.readOnly,mode:r,setMode(t){e.readOnly||e.disabled||t===r||(a(t),"relative"===t?(!i&&g||i)&&s(g?{type:"relative",value:g}:null):(!i&&h||i)&&s(h?{type:"absolute",value:h}:null))},datePickerState:u,relativeDateState:m,selectedDate:_,isActive:v,setActive:C}}const st=c("relative-date-picker");function nt(e){var t;const i=it(e),{groupProps:o,fieldProps:a,modeSwitcherProps:l,calendarButtonProps:c,popupProps:m,calendarProps:f,timeInputProps:_}=et(i,e),v=n.useRef(null),C=(0,W.N)(v,o.ref),b=(0,r.I)(),E=i.datePickerState.hasTime&&!i.datePickerState.hasDate;return(0,s.jsxs)("div",Object.assign({},o,{ref:C,className:st(null,e.className),children:[b&&"absolute"===i.mode&&(0,s.jsx)(Ge,{state:i.datePickerState,props:{id:e.id,disabled:e.disabled,readOnly:e.readOnly,placeholderValue:e.placeholderValue,timeZone:e.timeZone}}),(0,s.jsx)(u.k,Object.assign({},a,{controlProps:Object.assign(Object.assign({},a.controlProps),{disabled:b&&"absolute"===i.mode,className:st("input",{mobile:b&&"absolute"===i.mode})}),hasClear:e.hasClear&&!(b&&"absolute"===i.mode),startContent:(0,s.jsx)(g.$,Object.assign({},l,{children:(0,s.jsx)(p.I,{data:H})})),endContent:(0,s.jsxs)(n.Fragment,{children:[!b&&!E&&(0,s.jsx)(g.$,Object.assign({},c,{children:(0,s.jsx)(p.I,{data:d})})),!b&&E&&(0,s.jsx)(qe,{size:c.size,icon:B}),b&&"absolute"===i.mode&&(0,s.jsx)(qe,{size:c.size,icon:E?B:d})]})})),(0,s.jsx)(h,{name:e.name,value:null===(t=i.value)||void 0===t?void 0:t.type,disabled:i.disabled,form:e.form}),(0,s.jsx)(h,{name:e.name,value:i.value,toStringValue:e=>function(e){if(!e)return"";if("relative"===e.type)return e.value;return e.value.toISOString()}(e),onReset:e=>{i.setValue(e)},disabled:i.disabled,form:e.form}),!b&&!E&&(0,s.jsx)(U.z,Object.assign({},m,{anchorRef:v,children:(0,s.jsxs)("div",{className:st("popup-content"),children:["function"===typeof e.children?e.children(f):(0,s.jsx)(pe,Object.assign({},f)),i.datePickerState.hasTime&&(0,s.jsx)("div",{className:st("time-field-wrapper"),children:(0,s.jsx)(Ve,Object.assign({},_))})]})}))]}))}var rt=i(23871),ot=i(40091),at=i(73633),lt=i(87924),ct=i.n(lt),ht=i(81824),dt=i.n(ht),ut=i(61199),gt=i.n(ut),pt=i(69220),mt=i(27629);const ft=JSON.parse('{"label_empty":"No data","label-actions":"Actions","label-row-select":"Select"}'),_t=JSON.parse('{"label_empty":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445","label-actions":"\u0414\u0435\u0439\u0441\u0442\u0432\u0438\u044f","label-row-select":"\u0412\u044b\u0431\u0440\u0430\u0442\u044c"}'),vt=(0,_.N)({en:ft,ru:_t},"Table");function Ct(e){(0,mt.m)(`[Table] Physical values (left, right) of "${e}" property are deprecated. Use logical values (start, end) instead.`)}function bt(e,t){return"left"===e?(Ct(t),"start"):"right"===e?(Ct(t),"end"):e}const Et=(0,pt.om)("table");class St extends n.Component{constructor(){super(...arguments),this.state={activeScrollElement:"scrollContainer",columnsStyles:Array.from(this.props.columns,(()=>({}))),columnHeaderRefs:Array.from(this.props.columns,(()=>n.createRef()))},this.tableRef=n.createRef(),this.scrollContainerRef=n.createRef(),this.horizontalScrollBarRef=n.createRef(),this.horizontalScrollBarInnerRef=n.createRef(),this.renderRow=(e,t)=>{const{columns:i,isRowDisabled:s,onRowClick:r,onRowMouseEnter:o,onRowMouseLeave:a,onRowMouseDown:l,getRowClassNames:c,verticalAlign:h,edgePadding:d,wordWrap:u,getRowDescriptor:g}=this.props,{columnsStyles:p}=this.state,m=null===g||void 0===g?void 0:g(e,t),f=(null===m||void 0===m?void 0:m.disabled)||(null===s||void 0===s?void 0:s(e,t))||!1,_=(null===m||void 0===m?void 0:m.classNames)||(null===c||void 0===c?void 0:c(e,t))||[],v=Boolean(!f&&r);return n.createElement("tr",{key:St.getRowId(this.props,e,t),onClick:!f&&r?r.bind(null,e,t):void 0,onMouseEnter:!f&&o?o.bind(null,e,t):void 0,onMouseLeave:!f&&a?a.bind(null,e,t):void 0,onMouseDown:!f&&l?l.bind(null,e,t):void 0,className:Et("row",{disabled:f,interactive:v,"vertical-align":h},_.join(" "))},i.map(((i,s)=>{const{id:r,align:o,primary:a,className:l,sticky:c}=i,h=St.getBodyCellContent(i,e,t),g=bt(o,"column.align"),m=bt(c,"column.sticky");return n.createElement("td",{key:r,style:p[s],className:Et("cell",{align:g,primary:a,sticky:m,"edge-padding":d,"word-wrap":u},l)},h)})))},this.handleScrollContainerMouseenter=()=>{this.setState({activeScrollElement:"scrollContainer"})},this.handleScrollContainerScroll=()=>{"scrollContainer"===this.state.activeScrollElement&&this.horizontalScrollBarRef.current&&this.scrollContainerRef.current&&(this.horizontalScrollBarRef.current.scrollLeft=this.scrollContainerRef.current.scrollLeft)},this.handleHorizontalScrollBarMouseenter=()=>{this.setState({activeScrollElement:"scrollBar"})},this.handleHorizontalScrollBarScroll=()=>{"scrollBar"===this.state.activeScrollElement&&this.horizontalScrollBarRef.current&&this.scrollContainerRef.current&&(this.scrollContainerRef.current.scrollLeft=this.horizontalScrollBarRef.current.scrollLeft)}}static getRowId(e,t,i){const{data:s,getRowId:n,getRowDescriptor:r}=e,o=null!==i&&void 0!==i?i:s.indexOf(t),a=null===r||void 0===r?void 0:r(t,o);return void 0!==(null===a||void 0===a?void 0:a.id)?a.id:"function"===typeof n?n(t,o):String(n&&n in t?t[n]:o)}static getHeadCellContent(e){const{id:t,name:i}=e;let s;return s="function"===typeof i?i():"string"===typeof i?i:t,s}static getBodyCellContent(e,t,i){const{id:s,template:n,placeholder:r}=e;let o,a;return o="function"===typeof r?r(t,i):null!==r&&void 0!==r?r:"\u2014","function"===typeof n?a=n(t,i):"string"===typeof n?a=ct()(t,n):dt()(t,s)&&(a=ct()(t,s)),[void 0,null,""].includes(a)&&o?o:a}static getDerivedStateFromProps(e,t){return e.columns.length===t.columnHeaderRefs.length?null:{columnHeaderRefs:Array.from(e.columns,(()=>n.createRef()))}}componentDidMount(){this.props.stickyHorizontalScroll&&(this.tableResizeObserver=new ResizeObserver((e=>{var t;const{contentRect:i}=e[0];null===(t=this.horizontalScrollBarInnerRef.current)||void 0===t||t.style.setProperty("width",`${i.width}px`)})),this.tableRef.current&&this.tableResizeObserver.observe(this.tableRef.current),this.scrollContainerRef.current&&(this.scrollContainerRef.current.addEventListener("scroll",this.handleScrollContainerScroll),this.scrollContainerRef.current.addEventListener("mouseenter",this.handleScrollContainerMouseenter)),this.horizontalScrollBarRef.current&&(this.horizontalScrollBarRef.current.addEventListener("scroll",this.handleHorizontalScrollBarScroll),this.horizontalScrollBarRef.current.addEventListener("mouseenter",this.handleHorizontalScrollBarMouseenter))),this.columnsResizeObserver=new ResizeObserver((e=>{window.requestAnimationFrame((()=>{Array.isArray(e)&&e.length&&this.updateColumnStyles()}))})),this.tableRef.current&&this.columnsResizeObserver.observe(this.tableRef.current),this.updateColumnStyles()}componentDidUpdate(e){this.props.columns!==e.columns&&this.updateColumnStyles()}componentWillUnmount(){this.props.stickyHorizontalScroll&&(this.tableResizeObserver&&this.tableResizeObserver.disconnect(),this.scrollContainerRef.current&&(this.scrollContainerRef.current.removeEventListener("scroll",this.handleScrollContainerScroll),this.scrollContainerRef.current.removeEventListener("mouseenter",this.handleScrollContainerMouseenter)),this.horizontalScrollBarRef.current&&(this.horizontalScrollBarRef.current.removeEventListener("scroll",this.handleHorizontalScrollBarScroll),this.horizontalScrollBarRef.current.removeEventListener("mouseenter",this.handleHorizontalScrollBarMouseenter))),this.columnsResizeObserver&&this.columnsResizeObserver.disconnect()}render(){const{columns:e,stickyHorizontalScroll:t,className:i,qa:s}=this.props,r=e.some((({primary:e})=>e));return n.createElement("div",{className:Et({"with-primary":r,"with-sticky-scroll":t},i),"data-qa":s},t?n.createElement(n.Fragment,null,n.createElement("div",{ref:this.scrollContainerRef,className:Et("scroll-container")},this.renderTable()),this.renderHorizontalScrollBar()):this.renderTable())}renderHead(){const{columns:e,edgePadding:t,wordWrap:i}=this.props,{columnsStyles:s}=this.state;return n.createElement("thead",{className:Et("head")},n.createElement("tr",{className:Et("row")},e.map(((e,r)=>{const{id:o,align:a,primary:l,sticky:c,className:h}=e,d=bt(a,"column.align"),u=bt(c,"column.sticky"),g=St.getHeadCellContent(e);return n.createElement("th",{key:o,ref:this.state.columnHeaderRefs[r],style:s[r],className:Et("cell",{align:d,primary:l,sticky:u,"edge-padding":t,"word-wrap":i},h)},g)}))))}renderBody(){const{data:e}=this.props;return n.createElement("tbody",{className:Et("body")},e.length>0?e.map(this.renderRow):this.renderEmptyRow())}renderTable(){const{width:e="auto"}=this.props;return n.createElement("table",{ref:this.tableRef,className:Et("table",{width:e})},this.renderHead(),this.renderBody())}renderEmptyRow(){const{columns:e,emptyMessage:t}=this.props;return n.createElement("tr",{className:Et("row",{empty:!0})},n.createElement("td",{className:Et("cell"),colSpan:e.length},t||vt("label_empty")))}renderHorizontalScrollBar(){const{stickyHorizontalScroll:e,stickyHorizontalScrollBreakpoint:t=0}=this.props;return n.createElement("div",{ref:this.horizontalScrollBarRef,className:Et("horizontal-scroll-bar",{"sticky-horizontal-scroll":e}),style:{bottom:`${t}px`},"data-qa":"sticky-horizontal-scroll-breakpoint-qa"},n.createElement("div",{ref:this.horizontalScrollBarInnerRef,className:Et("horizontal-scroll-bar-inner")}))}updateColumnStyles(){this.setState((e=>{const t=e.columnHeaderRefs.map((e=>null===e.current?void 0:e.current.getBoundingClientRect().width));return{columnsStyles:this.props.columns.map(((e,i)=>this.getColumnStyles(i,t)))}}))}getColumnStyles(e,t){const{columns:i}=this.props,s=i[e],n={};if("string"===typeof s.width)return{maxWidth:0,width:s.width};if("undefined"!==typeof s.width&&(n.width=s.width),!s.sticky)return n;const r="left"===s.sticky||"start"===s.sticky?t.slice(0,e):t.slice(e+1);return n["left"===s.sticky||"start"===s.sticky?"insetInlineStart":"insetInlineEnd"]=r.reduce(((e,t)=>gt()(t)?e+t:e),0),n}}St.defaultProps={edgePadding:!0};var yt=i(84375);const wt=c("relative-range-date-picker-presets-doc"),Lt=[{id:"title",name:()=>b("Range")},{id:"from",name:()=>b("From")},{id:"to",name:()=>b("To")}],Rt=[{get title(){return b("Last 5 minutes")},from:"now - 5m",to:"now"},{get title(){return b("From start of day")},from:"now/d",to:"now"},{get title(){return b("This week")},from:"now/w",to:"now/w"},{get title(){return b("From start of week")},from:"now/w",to:"now"},{get title(){return b("Previous month")},from:"now - 1M/M",to:"now - 1M/M"}];function Tt({size:e,docs:t}){return(0,s.jsx)(St,{columns:Lt,data:t,className:wt("table",{size:e})})}function xt({className:e,size:t,docs:i}){return(0,s.jsx)(yt.A,{className:wt(null,e),tooltipContentClassName:wt("content"),hasArrow:!1,content:(0,s.jsx)(Tt,{size:t,docs:i}),children:(0,s.jsx)(g.$,{className:wt("button"),view:"flat-secondary",size:m(t),children:(0,s.jsx)(p.I,{data:at.A})})})}function kt({className:e,size:t,docs:i}){const[r,o]=n.useState(!1);return(0,s.jsxs)("div",{className:wt(null,e),children:[(0,s.jsx)(g.$,{className:wt("button"),view:"flat-secondary",size:"l",onClick:()=>{o(!0)},children:(0,s.jsx)(p.I,{data:at.A})}),(0,s.jsx)(F.c,{visible:r,onClose:()=>o(!1),children:(0,s.jsx)(Tt,{size:t,docs:i})})]})}function At({className:e,size:t,docs:i=Rt}){const n=(0,r.I)();return Array.isArray(i)&&0!==i.length?n?(0,s.jsx)(kt,{className:e,size:t,docs:i}):(0,s.jsx)(xt,{className:e,size:t,docs:i}):null}const Nt=c("relative-range-date-picker-presets");function It({className:e,size:t="m",minValue:i,withTime:r,onChoosePreset:o,presetTabs:a,docs:l}){var c,h;const d=n.useMemo((()=>function(e,{minValue:t}={}){return e.reduce(((e,i)=>{const s=x(i.presets,t);return s.length&&e.push(Object.assign(Object.assign({},i),{presets:s})),e}),[])}(null!==a&&void 0!==a?a:function({withTime:e,minValue:t}){const i=[],s={id:"main",title:b("Main"),presets:[]},n=E;e&&n.unshift(...S),s.presets=x(n,t),s.presets.length>0&&i.push(s);const r={id:"other",title:b("Other"),presets:x(y,t)};return r.presets.length>0&&i.push(r),i}({withTime:r}),{minValue:i})),[r,i,a]),[u,g]=n.useState(null===(c=d[0])||void 0===c?void 0:c.id);if(0===d.length)return null;const p=null!==(h=d.find((e=>e.id===u)))&&void 0!==h?h:d[0];return p?(p.id!==u&&g(p.id),(0,s.jsxs)("div",{className:Nt({size:t},e),children:[(0,s.jsxs)("div",{className:Nt("tabs"),children:[(0,s.jsx)(rt.t,{activeTab:u,onSelectTab:g,items:d,size:"s"===t?"m":t}),(0,s.jsx)(At,{className:Nt("doc"),size:t,docs:l})]}),(0,s.jsx)("div",{className:Nt("content"),children:(0,s.jsx)(Dt,{presets:p.presets,onChoosePreset:o,size:t})})]})):null}const Ot={s:28,m:28,l:32,xl:36};function Dt({presets:e,onChoosePreset:t,size:i="m"}){const r=n.useRef(null);return n.useEffect((()=>{var e,t;const i=r.current,s=null===(t=null===(e=r.current)||void 0===e?void 0:e.refContainer.current)||void 0===t?void 0:t.node;if(i&&s)try{s.setAttribute("tabindex","0"),s.setAttribute("class",Nt("list-container"));const e=()=>{null===i.getActiveItem()&&i.activateItem(0,!0)};return s.addEventListener("focus",e),()=>{s.removeEventListener("focus",e)}}catch(n){}}),[]),(0,s.jsx)(ot.B,{ref:r,className:Nt("list"),itemClassName:Nt("item"),items:e,filterable:!1,virtualized:!1,renderItem:e=>e.title,itemHeight:Ot[i],onItemClick:e=>{t(e.from,e.to)}})}var Mt=i(24555),Pt=i(98089);const Ft=JSON.parse('{"default":"Default","system":"Browser time"}'),Ut=JSON.parse('{"default":"\u0414\u0435\u0444\u043e\u043b\u0442\u043d\u0430\u044f","system":"\u0411\u0440\u0430\u0443\u0437\u0435\u0440\u043d\u043e\u0435 \u0432\u0440\u0435\u043c\u044f"}'),Ht=(0,_.N)({en:Ft,ru:Ut},`${l}relative-range-date-picker-zones`),Bt={},Wt=(0,f.Pn)().reduce(((e,t)=>{const[i]=t.split("/");if(i){let s=Bt[i];s||(s={label:i,options:[]},Bt[i]=s,e.push(s)),s.options.push({value:t})}return e}),[]);Wt.unshift({value:"UTC"}),Wt.unshift({value:"system",get content(){return Ht("system")}}),Wt.unshift({value:"default",get content(){return Ht("default")}});const Vt=c("relative-range-date-picker-zones");function zt(e){const t=k(e.value),i=e.isMobile?"xl":e.size;return(0,s.jsx)(Mt.l,{disabled:e.disabled,value:[t],options:Wt,size:i,onUpdate:t=>{const i=t[0];i&&e.onUpdate(i)},width:"max",renderControl:n=>{const r="system"===t||"default"===t?Ht(t):t;return(0,s.jsxs)(g.$,{onClick:n.onClick,ref:n.ref,view:"flat-secondary",width:"max",pin:"clear-clear",size:i,disabled:e.disabled,extraProps:{"aria-haspopup":"listbox","aria-expanded":n.open,onKeyDown:n.onKeyDown},className:Vt("control"),children:[`${r} (${A(t)})`,(0,s.jsx)(p.I,{className:Vt("control-icon"),data:z.A,size:e.isMobile?20:16})]})},renderOption:({value:e,content:t})=>{const i=null!==t&&void 0!==t?t:e;return(0,s.jsxs)("span",{className:Vt("item"),children:[(0,s.jsxs)("span",{className:Vt("item-title"),title:e,children:[i,"\xa0"]}),(0,s.jsx)(Pt.E,{color:"secondary",children:A(e)})]})},filterable:!0})}const Gt=JSON.parse('{"Value is incorrect.":"Value is incorrect.","Value is required.":"Value is required.","\\"From\\" can\'t be after \\"To\\".":"\\"From\\" can\'t be after \\"To\\".","From":"From","To":"To","Apply":"Apply"}'),jt=JSON.parse('{"Value is incorrect.":"\u0417\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \u043d\u0435\u043a\u043e\u0440\u0440\u0435\u043a\u0442\u043d\u043e.","Value is required.":"Value is required.","\\"From\\" can\'t be after \\"To\\".":"\u0417\u043d\u0430\u0447\u0435\u043d\u0438\u0435 \xab\u041e\u0442\xbb \u043d\u0435 \u043c\u043e\u0436\u0435\u0442 \u0431\u044b\u0442\u044c \u043f\u043e\u0437\u0436\u0435 \u0447\u0435\u043c \xab\u0414\u043e\xbb.","From":"\u041e\u0442","To":"\u0414o","Apply":"\u041f\u0440\u0438\u043c\u0435\u043d\u0438\u0442\u044c"}'),Kt=(0,_.N)({en:Gt,ru:jt},`${l}relative-range-date-picker-dialog`),Yt=JSON.parse('{"Value must be {minValue} or later.":"{{value}} must be {{minValue}} or later.","Value must be {maxValue} or earlier.":"{{value}} must be {{maxValue}} or earlier.","Selected date unavailable.":"Selected date unavailable.","Value is required.":"{{value}} is required."}'),qt=JSON.parse('{"Value must be {minValue} or later.":"{value} \u0434\u043e\u043b\u0436\u043d\u043e \u0440\u043e\u0432\u043d\u044f\u0442\u044c\u0441\u044f {minValue} \u0438\u043b\u0438 \u0431\u044b\u0442\u044c \u043f\u043e\u0437\u0436\u0435.","Value must be {maxValue} or earlier.":"{value} \u0434\u043e\u043b\u0436\u043d\u043e \u0440\u043e\u0432\u043d\u044f\u0442\u044c\u0441\u044f {maxValue} \u0438\u043b\u0438 \u0431\u044b\u0442\u044c \u0440\u0430\u043d\u044c\u0448\u0435.","Selected date unavailable.":"\u0412\u044b\u0431\u0440\u0430\u043d\u043d\u0430\u044f \u0434\u0430\u0442\u0430 \u043d\u0435\u0434\u043e\u0441\u0442\u0443\u043f\u043d\u0430.","Value is required.":"{value} \u043e\u0431\u044f\u0437\u0430\u0442\u0435\u043b\u044c\u043d\u043e."}'),$t=(0,_.N)({en:Yt,ru:qt},`${l}validation`);function Qt(e,t,i,s,n,r="Value"){const o=e&&i&&i.isBefore(e),a=e&&t&&e.isBefore(t),l=e&&(null===s||void 0===s?void 0:s(e))||!1,c=o||a||l,h=[];return c&&(a&&t&&h.push($t("Value must be {minValue} or later.",{minValue:t.timeZone(n).format(),value:r})),o&&i&&h.push($t("Value must be {maxValue} or earlier.",{maxValue:i.timeZone(n).format(),value:r})),l&&h.push($t("Selected date unavailable."))),{isInvalid:c,errors:h}}function Xt(e,t,i={}){var s;if(!e&&!t)return null;const{isInvalid:n}=Zt(e,t,i.allowNullableValues,i.minValue,i.maxValue,i.isDateUnavailable,null!==(s=i.timeZone)&&void 0!==s?s:"default");return n?null:{start:e,end:t}}function Zt(e,t,i,s,n,r,o){if(!e&&!t)return{isInvalid:!1};const a=e?(0,f.bQ)(e.value,{timeZone:o}):null,l=t?(0,f.bQ)(t.value,{timeZone:o,roundUp:!0}):null,c=Qt(a,s,n,r,o);a||i||(c.isInvalid=!0,c.errors.push(Kt("Value is required.")));const h=Qt(l,s,n,r,o);return l||i||(h.isInvalid=!0,h.errors.push(Kt("Value is required."))),a&&l&&l.isBefore(a)&&(c.isInvalid=!0,c.errors.push(Kt('"From" can\'t be after "To".'))),{isInvalid:c.isInvalid||h.isInvalid,startValidationResult:c,endValidationResult:h}}const Jt=c("relative-range-date-picker-dialog");function ei({props:e,state:t,open:i,onClose:n,focusInput:r,isMobile:o,anchorRef:a,className:l}){return o?(0,s.jsx)(F.c,{visible:i,onClose:n,contentClassName:Jt("content",{mobile:!0,size:"xl"},l),children:(0,s.jsx)(ti,Object.assign({},e,{size:"xl",state:t,onApply:n}))}):(0,s.jsx)(U.z,{open:i,onEscapeKeyDown:()=>{n(),r()},onClose:n,role:"dialog",anchorRef:a,contentClassName:Jt("content",{size:e.size},l),autoFocus:!0,focusTrap:!0,children:(0,s.jsx)(ti,Object.assign({},e,{state:t,onApply:n}))})}function ti(e){var t,i,r,o,a,l,c;const h=function(e,t){var i,s,r,o;const{withApplyButton:a,allowNullableValues:l}=t,[c,h]=n.useState(null!==(s=null===(i=e.value)||void 0===i?void 0:i.start)&&void 0!==s?s:null),[d,u]=n.useState(null!==(o=null===(r=e.value)||void 0===r?void 0:r.end)&&void 0!==o?o:null),[g,p]=n.useState(e.timeZone),m=a?g:e.timeZone,f=n.useMemo((()=>Zt(c,d,l,t.minValue,t.maxValue,t.isDateUnavailable,m)),[l,d,t.isDateUnavailable,t.maxValue,t.minValue,c,m]);return{start:c,end:d,timeZone:m,setStart:function(i){h(i),a||e.setValue(Xt(i,d,Object.assign(Object.assign({},t),{timeZone:m})),m)},setEnd:function(i){u(i),a||e.setValue(Xt(c,i,Object.assign(Object.assign({},t),{timeZone:m})),m)},setRange:function(i,s){h(i),u(s),a||e.setValue(Xt(i,s,Object.assign(Object.assign({},t),{timeZone:m})),m)},setTimeZone:function(i){p(i),a||e.setValue(Xt(c,d,Object.assign(Object.assign({},t),{timeZone:i})),i)},applyValue:function(){e.setValue(Xt(c,d,Object.assign(Object.assign({},t),{timeZone:m})),m)},isInvalid:f.isInvalid,startValidation:f.startValidationResult,endValidation:f.endValidationResult}}(e.state,e),d=(null===(t=e.placeholderValue)||void 0===t?void 0:t.timeZone(e.state.timeZone))||(0,f.KQ)({timeZone:e.state.timeZone}),u={timeZone:e.state.timeZone,format:e.format,minValue:e.minValue,maxValue:e.maxValue,hasClear:e.allowNullableValues,readOnly:e.readOnly,size:e.size,errorPlacement:"inside"};return(0,s.jsxs)("div",{children:[(0,s.jsxs)("div",{className:Jt("pickers"),children:[(0,s.jsx)(nt,Object.assign({},u,{validationState:(null===(i=h.startValidation)||void 0===i?void 0:i.isInvalid)?"invalid":void 0,errorMessage:(null===(o=null===(r=h.startValidation)||void 0===r?void 0:r.errors)||void 0===o?void 0:o.join("\n"))||Kt("Value is incorrect."),placeholderValue:d.startOf("day"),label:Kt("From"),value:h.start,onUpdate:h.setStart})),(0,s.jsx)(nt,Object.assign({},u,{validationState:(null===(a=h.endValidation)||void 0===a?void 0:a.isInvalid)?"invalid":void 0,errorMessage:(null===(c=null===(l=h.endValidation)||void 0===l?void 0:l.errors)||void 0===c?void 0:c.join("\n"))||Kt("Value is incorrect."),placeholderValue:d.endOf("day"),label:Kt("To"),value:h.end,onUpdate:h.setEnd,roundUp:!0}))]}),e.withApplyButton&&!e.readOnly?(0,s.jsx)(g.$,{disabled:h.isInvalid,size:e.size,onClick:()=>{h.applyValue(),e.onApply()},className:Jt("apply"),width:"max",children:Kt("Apply")}):null,e.withPresets&&!e.readOnly?(0,s.jsx)(It,{size:e.size,presetTabs:e.presetTabs,onChoosePreset:(t,i)=>{h.setRange({type:"relative",value:t},{type:"relative",value:i}),e.withApplyButton||e.onApply()},minValue:e.minValue,docs:e.docs,className:Jt("presets")}):null,e.withZonesList?(0,s.jsx)("div",{className:Jt("zone"),children:(0,s.jsx)(zt,{value:h.timeZone,onUpdate:h.setTimeZone,disabled:e.readOnly,size:e.size})}):null]})}const ii=JSON.parse('{"\\"From\\"":"\\"From\\"","\\"From\\" is required.":"\\"From\\" is required.","\\"To\\"":"\\"To\\"","\\"To\\" is required.":"\\"To\\" is required.","\\"From\\" can\'t be after \\"To\\".":"\\"From\\" can\'t be after \\"To\\".","to":"to"}'),si=JSON.parse('{"\\"From\\"":"\xab\u041e\u0442\xbb","\\"From\\" is required.":"\xab\u041e\u0442\xbb \u043e\u0431\u044f\u0437\u0430\u0442\u0435\u043b\u044c\u043d\u043e.","\\"To\\"":"\xab\u0414\u043e\xbb","\\"To\\" is required.":"\xab\u0414\u043e\xbb \u043e\u0431\u044f\u0437\u0430\u0442\u0435\u043b\u044c\u043d\u043e.","\\"From\\" can\'t be after \\"To\\".":"\xab\u041e\u0442\xbb \u043d\u0435 \u043c\u043e\u0436\u0435\u0442 \u0431\u044b\u0442\u044c \u043f\u043e\u0437\u0436\u0435 \u0447\u0435\u043c \xab\u0414\u043e\xbb.","to":"\u0434\u043e"}'),ni=(0,_.N)({en:ii,ru:si},`${l}relative-range-date-picker`);function ri(e){var t,i;const[s,r]=(0,o.P)(e.value,null!==(t=e.defaultValue)&&void 0!==t?t:null),[a,l]=(0,o.P)(e.timeZone,null!==(i=e.defaultTimeZone)&&void 0!==i?i:"default",e.onUpdateTimeZone),c=n.useMemo((()=>function(e,t,i,s,n,r){if(!e)return{isInvalid:!1,errors:[]};const o=e.start?(0,f.bQ)(e.start.value,{timeZone:r}):null,a=e.end?(0,f.bQ)(e.end.value,{timeZone:r,roundUp:!0}):null,l=Qt(o,i,s,n,r,ni('"From"'));o||t||(l.isInvalid=!0,l.errors.push(ni('"From" is required.')));const c=Qt(a,i,s,n,r,ni('"To"'));a||t||(c.isInvalid=!0,c.errors.push(ni('"To" is required.')));o&&a&&a.isBefore(o)&&(l.isInvalid=!0,l.errors.push(ni('"From" can\'t be after "To".')));return{isInvalid:l.isInvalid||c.isInvalid,errors:l.errors.concat(c.errors)}}(s,e.allowNullableValues,e.minValue,e.maxValue,e.isDateUnavailable,a)),[s,e.allowNullableValues,e.isDateUnavailable,e.maxValue,e.minValue,a]);return Object.assign({value:s,timeZone:a,setValue(t,i){var n;r(t),l(i),(s!==t||s&&a!==i)&&(null===(n=e.onUpdate)||void 0===n||n.call(e,t,i))}},c)}const oi=c("relative-range-date-picker");function ai(e){const t=ri(e),i=(0,r.I)(),l=n.useRef(null),c=n.useRef(null),[d,u]=n.useState(!1),[g,p]=(0,o.P)(void 0,!1,e.onOpenChange),{focusWithinProps:m}=(0,a.R)({isDisabled:e.disabled,onFocusWithin:t=>{var i;d||null===(i=e.onFocus)||void 0===i||i.call(e,t)},onBlurWithin:t=>{var i;g||(u(!1),null===(i=e.onBlur)||void 0===i||i.call(e,t))}});return(0,s.jsxs)("div",Object.assign({ref:l},m,{className:oi(null,e.className),style:e.style,children:[(0,s.jsx)(P,{props:e,state:t,open:g,isMobile:i,ref:c,onClick:()=>{e.disabled||g||(u(!0),p(!0))},onKeyDown:t=>{e.disabled||!t.altKey||"ArrowDown"!==t.key&&"ArrowUp"!==t.key||(t.preventDefault(),p(!0))},onClickCalendar:()=>{u(!0),p(!g)},onFocus:()=>{d||(u(!0),p(!0))},onUpdate:i=>{e.readOnly||i||t.setValue(null,"default")}}),(0,s.jsx)(h,{name:e.name,form:e.form,value:t.value,toStringValue:e=>{var t,i;return null!==(i=null===(t=null===e||void 0===e?void 0:e.start)||void 0===t?void 0:t.type)&&void 0!==i?i:""},disabled:e.disabled}),(0,s.jsx)(h,{name:e.name,form:e.form,value:t.value,toStringValue:e=>{var t;return li(null!==(t=null===e||void 0===e?void 0:e.start)&&void 0!==t?t:null)},disabled:e.disabled}),(0,s.jsx)(h,{name:e.name,form:e.form,value:t.value,toStringValue:e=>{var t,i;return null!==(i=null===(t=null===e||void 0===e?void 0:e.end)||void 0===t?void 0:t.type)&&void 0!==i?i:""},disabled:e.disabled}),(0,s.jsx)(h,{name:e.name,form:e.form,value:t.value,toStringValue:e=>{var t;return li(null!==(t=null===e||void 0===e?void 0:e.end)&&void 0!==t?t:null)},disabled:e.disabled}),(0,s.jsx)(h,{name:e.name,form:e.form,onReset:e=>{t.setValue(e.value,e.timeZone)},value:{value:t.value,timeZone:t.timeZone},toStringValue:e=>e.timeZone,disabled:e.disabled}),(0,s.jsx)(ei,{state:t,props:e,open:g,onClose:()=>{p(!1)},focusInput:()=>{setTimeout((()=>{var e;null===(e=c.current)||void 0===e||e.focus({preventScroll:!0})}))},anchorRef:l,isMobile:i,className:e.popupClassName})]}))}function li(e){return e?"relative"===e.type?e.value:e.value.toISOString():""}},92159:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8.53 11.78a.75.75 0 0 1-1.06 0l-2.5-2.5a.75.75 0 0 1 1.06-1.06l1.22 1.22V1.75a.75.75 0 0 1 1.5 0v7.69l1.22-1.22a.75.75 0 1 1 1.06 1.06zM1.75 13.5a.75.75 0 0 0 0 1.5h12.5a.75.75 0 0 0 0-1.5z",clipRule:"evenodd"}))},58272:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M11.323 12.383a5.5 5.5 0 0 1-7.706-7.706zm1.06-1.06L4.677 3.617a5.5 5.5 0 0 1 7.706 7.706M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0",clipRule:"evenodd"}))},53472:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M10.97 12.53a.75.75 0 1 0 1.06-1.06l-3.5-3.5a.75.75 0 0 0-1.06 0l-3.5 3.5a.75.75 0 1 0 1.06 1.06L8 9.56zm0-5a.75.75 0 1 0 1.06-1.06l-3.5-3.5a.75.75 0 0 0-1.06 0l-3.5 3.5a.75.75 0 0 0 1.06 1.06L8 4.56z",clipRule:"evenodd"}))},64280:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14M6.44 4.54c.43-.354.994-.565 1.56-.565 1.217 0 2.34.82 2.34 2.14 0 .377-.079.745-.298 1.1-.208.339-.513.614-.875.867-.217.153-.326.257-.379.328-.038.052-.038.07-.038.089a.75.75 0 0 1-1.5 0c0-.794.544-1.286 1.056-1.645.28-.196.402-.332.46-.425a.54.54 0 0 0 .073-.313c0-.3-.243-.641-.839-.641a1 1 0 0 0-.608.224c-.167.137-.231.286-.231.417a.75.75 0 0 1-1.5 0c0-.673.345-1.22.78-1.577M9 11a1 1 0 1 1-2 0 1 1 0 0 1 2 0",clipRule:"evenodd"}))},45345:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.5 8a5.5 5.5 0 1 1-11 0 5.5 5.5 0 0 1 11 0M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0M5.25 6.25a1 1 0 0 1 1-1h3.5a1 1 0 0 1 1 1v3.5a1 1 0 0 1-1 1h-3.5a1 1 0 0 1-1-1z",clipRule:"evenodd"}))},10800:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M13.5 8a5.5 5.5 0 1 1-11 0 5.5 5.5 0 0 1 11 0M15 8A7 7 0 1 1 1 8a7 7 0 0 1 14 0M6.53 5.47a.75.75 0 0 0-1.06 1.06L6.94 8 5.47 9.47a.75.75 0 1 0 1.06 1.06L8 9.06l1.47 1.47a.75.75 0 1 0 1.06-1.06L9.06 8l1.47-1.47a.75.75 0 1 0-1.06-1.06L8 6.94z",clipRule:"evenodd"}))},65872:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M11.423 1A3.577 3.577 0 0 1 15 4.577c0 .27-.108.53-.3.722l-.528.529-1.971 1.971-5.059 5.059a3 3 0 0 1-1.533.82l-2.638.528a1 1 0 0 1-1.177-1.177l.528-2.638a3 3 0 0 1 .82-1.533l5.059-5.059 2.5-2.5c.191-.191.451-.299.722-.299m-2.31 4.009-4.91 4.91a1.5 1.5 0 0 0-.41.766l-.38 1.903 1.902-.38a1.5 1.5 0 0 0 .767-.41l4.91-4.91a2.08 2.08 0 0 0-1.88-1.88m3.098.658a3.6 3.6 0 0 0-1.878-1.879l1.28-1.28c.995.09 1.788.884 1.878 1.88z",clipRule:"evenodd"}))},96589:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 6.5a2 2 0 1 0 0-4 2 2 0 0 0 0 4M8 8a3.5 3.5 0 1 0 0-7 3.5 3.5 0 0 0 0 7m1 1.225a.71.71 0 0 0-.679-.72A11 11 0 0 0 8 8.5c-3.85 0-7 2-7 4A2.5 2.5 0 0 0 3.5 15h2.25a.75.75 0 0 0 0-1.5H3.5a1 1 0 0 1-1-1c0-.204.22-.809 1.32-1.459C4.838 10.44 6.32 10 8 10q.088 0 .175.002c.442.008.825-.335.825-.777m3.59.307c.434.102.776.444.879.878l-2.823 2.822a1.5 1.5 0 0 1-.848.425l-.53.075.075-.53a1.5 1.5 0 0 1 .425-.848zm-.883 4.76 3.068-3.067a.77.77 0 0 0 .225-.543A2.683 2.683 0 0 0 12.318 8a.77.77 0 0 0-.543.224l-3.068 3.069a3 3 0 0 0-.848 1.697l-.17 1.19a1 1 0 0 0 1.13 1.131l1.191-.17a3 3 0 0 0 1.697-.848",clipRule:"evenodd"}))},594:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("g",{clipPath:"url(#a)"},s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M14.756 10.164c1.665-.962 1.665-3.366 0-4.329L6.251.918C4.585-.045 2.5 1.158 2.5 3.083v9.834c0 1.925 2.085 3.128 3.751 2.164z",clipRule:"evenodd"})),s.createElement("defs",null,s.createElement("clipPath",{id:"a"},s.createElement("path",{fill:"currentColor",d:"M0 0h16v16H0z"}))))},93844:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("g",{clipPath:"url(#a)"},s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M9.235 1a.75.75 0 0 1 .74.56l2.034 7.726 1.09-1.908A.75.75 0 0 1 13.75 7h1.5a.75.75 0 0 1 0 1.5h-1.065l-1.784 3.122a.75.75 0 0 1-1.376-.181l-1.71-6.496-2.083 9.466a.75.75 0 0 1-1.446.07L3.544 7.55l-.65 1.085A.75.75 0 0 1 2.25 9H.75a.75.75 0 1 1 0-1.5h1.075l1.282-2.136a.75.75 0 0 1 1.357.155l1.898 5.868 2.156-9.798A.75.75 0 0 1 9.235 1",clipRule:"evenodd"})),s.createElement("defs",null,s.createElement("clipPath",{id:"a"},s.createElement("path",{fill:"currentColor",d:"M0 0h16v16H0z"}))))},1956:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M4.5 3h7A1.5 1.5 0 0 1 13 4.5v7a1.5 1.5 0 0 1-1.5 1.5h-7A1.5 1.5 0 0 1 3 11.5v-7A1.5 1.5 0 0 1 4.5 3m-3 1.5a3 3 0 0 1 3-3h7a3 3 0 0 1 3 3v7a3 3 0 0 1-3 3h-7a3 3 0 0 1-3-3zm10.092 1.46a.75.75 0 0 0-1.184-.92L7.43 8.869l-1.4-1.4A.75.75 0 0 0 4.97 8.53l2 2a.75.75 0 0 0 1.122-.07z",clipRule:"evenodd"}))},31819:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M4.5 3A1.5 1.5 0 0 0 3 4.5v1.75a.75.75 0 0 1-1.5 0V4.5a3 3 0 0 1 3-3h1.75a.75.75 0 0 1 0 1.5zM9 2.25a.75.75 0 0 1 .75-.75h1.75a3 3 0 0 1 3 3v1.75a.75.75 0 0 1-1.5 0V4.5A1.5 1.5 0 0 0 11.5 3H9.75A.75.75 0 0 1 9 2.25M2.25 9a.75.75 0 0 1 .75.75v1.75A1.5 1.5 0 0 0 4.5 13h1.75a.75.75 0 0 1 0 1.5H4.5a3 3 0 0 1-3-3V9.75A.75.75 0 0 1 2.25 9m11.5 0a.75.75 0 0 1 .75.75v1.75a3 3 0 0 1-3 3H9.75a.75.75 0 0 1 0-1.5h1.75a1.5 1.5 0 0 0 1.5-1.5V9.75a.75.75 0 0 1 .75-.75",clipRule:"evenodd"}))},46649:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M12 3.5H4A1.5 1.5 0 0 0 2.5 5v6A1.5 1.5 0 0 0 4 12.5h8a1.5 1.5 0 0 0 1.5-1.5V5A1.5 1.5 0 0 0 12 3.5M4 2a3 3 0 0 0-3 3v6a3 3 0 0 0 3 3h8a3 3 0 0 0 3-3V5a3 3 0 0 0-3-3zm.47 8.53a.75.75 0 0 1 0-1.06L5.94 8 4.47 6.53a.75.75 0 0 1 1.06-1.06l2 2a.75.75 0 0 1 0 1.06l-2 2a.75.75 0 0 1-1.06 0M8.75 9.5a.75.75 0 0 0 0 1.5h2.5a.75.75 0 0 0 0-1.5z",clipRule:"evenodd"}))},64470:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(59284);const n=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M9 2H7a.5.5 0 0 0-.5.5V3h3v-.5A.5.5 0 0 0 9 2m2 1v-.5a2 2 0 0 0-2-2H7a2 2 0 0 0-2 2V3H2.251a.75.75 0 0 0 0 1.5h.312l.317 7.625A3 3 0 0 0 5.878 15h4.245a3 3 0 0 0 2.997-2.875l.318-7.625h.312a.75.75 0 0 0 0-1.5zm.936 1.5H4.064l.315 7.562A1.5 1.5 0 0 0 5.878 13.5h4.245a1.5 1.5 0 0 0 1.498-1.438zm-6.186 2v5a.75.75 0 0 0 1.5 0v-5a.75.75 0 0 0-1.5 0m3.75-.75a.75.75 0 0 1 .75.75v5a.75.75 0 0 1-1.5 0v-5a.75.75 0 0 1 .75-.75",clipRule:"evenodd"}))},73253:(e,t,i)=>{"use strict";i.d(t,{og:()=>R,SO:()=>me});var s=i(7252);function n(e,t){const i=document.createElement("button");return i.innerText=e,i.className=`paranoid-button paranoid-button_${t}`,i}const r="ParanoidC";function o(e,t){const i=document.getElementById(e);if(!i)throw new Error(`Not found element with id ${e}`);i.style.position="relative";const o=n("+","plus"),a=n("-","minus"),l=n("1:1","normal"),c=function(e,t){const i=document.createElement("canvas");i.setAttribute("id",r),i.setAttribute("width",String(e.offsetWidth)),i.setAttribute("height",String(e.offsetHeight)),e.appendChild(i);const n=t.colors||{};return new s.fabric.Canvas(r,{selection:!1,backgroundColor:n.fill,defaultCursor:"grab"})}(i,t),h=function(e,t,i,s){const n=document.createElement("div");n.className="paranoid-controls";const r=document.createElement("style");return r.innerText=function(e){return`\n .paranoid-controls {\n position: absolute;\n top: 10px;\n right: 10px;\n }\n .paranoid-button {\n margin-left: 12px;\n border-radius: 4px;\n height: 36px;\n width: 36px;\n line-height: 13px;\n font-family: Arial, sans-serif;\n font-size: 13px;\n text-align: center;\n padding: 0;\n box-shadow: 0px 5px 6px ${e.nodeShadow};\n border: 1px solid ${e.buttonBorderColor};\n background-color: ${e.nodeFill};\n color: ${e.textColor};\n cursor: pointer;\n }\n .paranoid-button:focus {\n outline: none;\n }\n .paranoid-button:active {\n border: 1px solid ${e.buttonBorderColor};\n }\n .paranoid-button_plus {\n margin-left: 0;\n border-left: none;\n border-top-left-radius: 0;\n border-bottom-left-radius: 0;\n }\n .paranoid-button_minus {\n border-top-right-radius: 0;\n border-bottom-right-radius: 0;\n }\n`}(s),n.appendChild(r),n.appendChild(t),n.appendChild(e),n.appendChild(i),n}(o,a,l,t.colors);return i.appendChild(h),function(e,t,i,s,n){const r=n.minZoom||.2,o=n.zoomStep||.2,a=n.maxZoom||2,l=n.startZoom||1;e.setZoom(l),i.addEventListener("click",(t=>{t.preventDefault(),t.stopPropagation();let i=e.getZoom();i-=o,i{t.preventDefault(),t.stopPropagation();let i=e.getZoom();i+=o,i>a&&(i=a),e.setZoom(i)})),s.addEventListener("click",(t=>{t.preventDefault(),t.stopPropagation(),e.setZoom(1)}))}(c,o,a,l,t),function(e){let t=!1,i=0,s=0;e.on("mouse:down",(n=>{n.target||(e.setCursor("grabbing"),t=!0,i=n.pointer.x,s=n.pointer.y)})),e.on("mouse:move",(n=>{t&&(e.viewportTransform[4]+=n.pointer.x-i,e.viewportTransform[5]+=n.pointer.y-s,e.setCursor("grabbing"),e.getObjects().forEach((e=>e.setCoords())),e.requestRenderAll(),i=n.pointer.x,s=n.pointer.y)})),e.on("mouse:up",(()=>{t&&(e.setCursor("grab"),t=!1)}))}(c),c}const a={success:"rgba(59, 201, 53, 0.75)",error:"#ff0400",warning:"#ff7700",errorBackground:"rgba(235,50,38,0.08)",warningBackground:"rgba(255,219,77,0.3)",mute:"rgba(0,0,0,0.15)",stroke:"rgba(0,0,0,0.3)",fill:"#fafafa",nodeFill:"#ffffff",nodeShadow:"rgba(0,0,0,0.15)",titleColor:"#000000",textColor:"rgba(0,0,0,0.7)",buttonBorderColor:"rgba(0,0,0,0.07)",groupBorderColor:"rgba(2, 123, 243, 0.14)",groupFill:"rgba(2, 123, 243, 0.08)",titleHoverColor:"#004080",nodeHover:"#f3f3f3",specialHover:"rgba(2,123,243,1)"},l={hasControls:!1,hasRotatingPoint:!1,lockMovementX:!0,lockMovementY:!0,selectable:!1,hoverCursor:"default",subTargetCheck:!0},c="Arial, sans-serif",h=13,d=1.38;var u;!function(e){e.Group="GROUP"}(u||(u={}));i(32133);class g{constructor(e,t){this.children=[],this.members=[],this.data=e,this.canvasNode=t}add(e,t){const i=new g(e,t);i.addParent(this),this.children.push(i)}addNode(e){e.addParent(this),this.children.push(e)}addNodes(e){e.forEach((e=>{e.addParent(this)})),this.children=this.children.concat(e)}addCanvasNode(e){this.canvasNode=e}addShapeInstance(e){this.shapeInstance=e}hasChildren(){return this.children.length>0}addParent(e){this.parent=e}getLeftSibling(){if(!this.parent)return;const e=this.parent.children.findIndex((e=>e===this));return this.parent.children[e-1]}getRightSibling(){if(!this.parent)return;const e=this.parent.children.findIndex((e=>e===this));return this.parent.children[e+1]}}class p{constructor(e){this.nodesWithChildren=[],this.root=e}traverseBF(e){const t=[this.root];for(;t.length>0;){const i=t.shift();i&&(t.push(...i.children),e(i))}}traverseDF(e){const t=[this.root];for(;t.length;){const i=t.shift();let s=!1;i&&(i.children.length>0?t.unshift(...i.children):s=!0,e(i,s))}}traverseByLevels(e){let t=0,i=this.root.children;for(e([this.root],0);i.length>0;)t++,e(i,t),i=i.reduce(((e,t)=>e.concat(t.children)),[])}getTreeDepth(){let e=0;return this.traverseByLevels(((t,i)=>{e=i})),e}setCanvas(e){this.canvas=e}setNodesWithChildren(e){this.nodesWithChildren=e}}class m{constructor(e,t){this.nodes=new Map,this.data=e,this.opts=t}parseData(){const e=this.data,t=this.getGroups(e),i=[...e.nodes];t.forEach(((e,t)=>{i.push({name:t,children:e,type:u.Group})}));const s=this.findSources(i,e.links);let n=[],r={},o=new Map;return s.forEach((t=>{const s=this.mapNodesToTree(t,i,e.links);r=Object.assign(Object.assign({},s.groups),r),o=new Map([...o,...s.notGroupMemebersChildren]),n.push(s.tree)})),o.forEach(((e,t)=>{r[t]&&r[t].addNodes(e)})),n=n.reduce(((e,t)=>{const i=t.root.data.group;return i?r[i].members.push(t):e.push(t),e}),[]),n}getGroups({nodes:e}){const t=new Map;return e.forEach((e=>{if(e.group){const i=t.get(e.group);i?i.push(e.name):t.set(e.group,[e.name])}})),t}findSources(e,t){const i=t.map((({to:e})=>e));return e.reduce(((e,t)=>(i.includes(t.name)||e.push(t),e)),[])}mapNodesToTree(e,t,i){var s;const n=this.createNode(e),r={};this.appendGoup(r,n);const o=t.map((e=>{const t=i.reduce(((t,i)=>(i.from===e.name&&t.push(i.to),t)),[]);return Object.assign(Object.assign({},e),{children:t})})),a=this.getAppender(o,r)(n,(null===(s=o.find((t=>t.name===e.name)))||void 0===s?void 0:s.children)||[]);return{tree:new p(n),groups:r,notGroupMemebersChildren:a}}appendGoup(e,t){const i=t.data;t.data.type===u.Group&&(e[i.name]=t)}getAppender(e,t){const i=new Map,s=(n,r)=>{const o=r.map((i=>{const n=e.find((({name:e})=>e===i)),r=this.createNode(n);return this.appendGoup(t,r),n.children.length>0&&s(r,n.children),r})),a=n.data.group,l=Boolean(a),c=[],h=[];if(o.forEach((e=>{const t=e.data.group;l?a===t?c.push(e):h.push(e):c.push(e)})),n.addNodes(c),a&&h.length>0){const e=i.get(a);e?e.push(...h):i.set(a,h)}return i};return s}createNode(e){const t=new g(e);return this.nodes.set(e.name,t),t}}class f extends CustomEvent{}class _ extends EventTarget{dispatch(e,t){this.dispatchEvent(new f(e,{detail:t}))}}function v(e){switch(e){case 0:return 0;case 1:return 16;default:return 24}}function C(e,t,i,s,n,r){const o=function(e,t,i,s,n,r,o){const a=new Map,l=new Map,c=new Map,h=[];return s.traverseBF((s=>{const{object:n,width:r,height:l}=function(e,t,i,s,n,r,o){var a,l;const c=null!==(a=t.shapeInstance)&&void 0!==a?a:r.node(e,{top:i,left:s},t,n,o),h=null!==(l=t.canvasNode)&&void 0!==l?l:c.getShape();return t.addShapeInstance(c),t.addCanvasNode(h),{object:h,top:i,left:s,width:h.getScaledWidth(),height:h.getScaledHeight()}}(e,s,0,0,t,i,o);a.set(s,{width:r,height:l}),h.push(n)})),function e(t){const{width:i}=a.get(t);let s=i,n=0;if(t.parent&&1===t.parent.children.length&&l.has(t.parent)){const e=l.get(t.parent);s0&&(n=16*(t.children.length-1)+t.children.reduce(((t,i)=>t+e(i)),0),c.set(t,n)),s=Math.max(s,n),l.set(t,s),s}(s.root),function e(t,i,s){let n=s,r=s;for(const o of t){const{width:t,height:s}=a.get(o),h=l.get(o),d=i,u=n+Math.floor(h/2)-Math.floor(t/2);if(o.canvasNode.set({top:d,left:u}),o.canvasNode.setCoords(),n=n+h+16,o.children.length){let t=0;const n=c.get(o);n{a=Math.max(a,(e.left||0)+e.getScaledWidth()),l=Math.max(l,(e.top||0)+e.getScaledHeight())})),{nodes:o,bottom:l,right:a}}function b(e){const t=e.canvasNode;if(t){const e=t.left||0,i=(t.top||0)+t.getScaledHeight();return{x:e+t.getScaledWidth()/2,y:i}}return{x:0,y:0}}function E(e){const t=e.canvasNode;if(t){const e=t.left||0,i=t.top||0;return{x:e+t.getScaledWidth()/2,y:i}}return{x:0,y:0}}class S{constructor(e,t,i,s){this.canvas=o(e,t),this.parser=new m(i,t),this.opts=t,this.shapes=s,this.em=new _,this.trees=[],this.nodes=[],this.links=[],this.listenNodeResize()}render(){requestAnimationFrame((()=>{this.trees=this.parser.parseData(),this.renderIntoCanvas(),this.opts.initialZoomFitsCanvas&&this.zoomObjectsToFitCanvas()}))}destroy(){const e=document.getElementById(r);e&&(this.canvas.dispose(),e.remove())}getEventEmmiter(){return this.em}getGraphNode(e){return this.parser.nodes.get(e)}getOpts(){return this.opts}getColors(){return this.opts.colors}getCanvas(){return this.canvas}renderIntoCanvas(){this.nodes.forEach((e=>{this.canvas.remove(e)})),this.nodes=[],this.links.forEach((e=>{this.canvas.remove(e)})),this.links=[];const e=this.canvas.getHeight()||0,t=this.canvas.getWidth()||0;let i=e,n=t;const r=this.opts.initialTop;let o=this.opts.initialLeft;this.trees.forEach((e=>{e.setCanvas(this.canvas);const{nodes:t,bottom:s,right:a}=C(e,r,o,this.opts,this.shapes,this.em);o=a+15,i=Math.max(s,i),n=Math.max(a,n),this.nodes.push(...t),this.canvas.add(...t)}));const a=function(e,t){const i=t.colors,n=[];return e.data.links.reduce(((t,{from:r})=>{const o=e.nodes.get(r);if(o&&1===o.children.length&&!n.includes(r)){const{x:e,y:a}=b(o),c=new s.fabric.Path(`M ${e} ${a}\n V ${a+16}`,{fill:"",stroke:i.stroke,strokeWidth:1});t.push(new s.fabric.Group([c],Object.assign({},l))),n.push(r)}if(o&&o.children.length>1&&!n.includes(r)){const{x:e,y:a}=b(o),c=12,h=6,d=[new s.fabric.Path(`M ${e} ${a}\n V ${a+c}`,{fill:"",stroke:i.stroke,strokeWidth:1})],{x:u,y:g}=E(o.children[0]),{x:p,y:m}=E(o.children[o.children.length-1]),f=new s.fabric.Path(`M ${u} ${g}\n V ${g-c+h}\n Q ${u} ${g-c} ${u+h} ${g-c}\n H ${p-h}\n Q ${p} ${m-c} ${p} ${m+h-c}\n V ${m}\n `,{fill:"",stroke:i.stroke,strokeWidth:1});d.push(f),o.children.forEach(((e,t)=>{if(0===t||t===o.children.length-1)return;const{x:n,y:r}=E(e),a=new s.fabric.Path(`M ${n} ${r}\n V ${r-c}\n `,{fill:"",stroke:i.stroke,strokeWidth:1});d.push(a)})),t.push(new s.fabric.Group(d,Object.assign({},l))),n.push(r)}return t}),[])}(this.parser,this.opts);this.links.push(...a),this.canvas.add(...a),this.bringNodesToFront()}bringNodesToFront(){var e;const t=null===(e=this.parser)||void 0===e?void 0:e.nodes;t&&t.forEach((e=>{e.canvasNode&&e.canvasNode.bringToFront()}))}listenNodeResize(){this.em.addEventListener("node:resize",(()=>{this.renderIntoCanvas()}))}zoomObjectsToFitCanvas(){let e=0,t=0;this.canvas.getObjects().forEach((i=>{const{top:s,left:n,height:r,width:o}=i.getBoundingRect(),a=n+o,l=s+r;a>e&&(e=a),l>t&&(t=l)})),e+=this.opts.initialLeft,t+=this.opts.initialTop;const i=this.canvas.getWidth()/e,n=this.canvas.getHeight()/t,r=Math.min(i,n);if(r<1){this.canvas.setZoom(r);const e=this.opts.initialTop*r,t=this.opts.initialLeft*r,i=this.opts.initialTop-e,n=this.opts.initialLeft-t;this.canvas.relativePan(new s.fabric.Point(n,i))}}}function y(){const e={success:"--g-color-text-positive",error:"--g-color-text-danger",warning:"--g-color-text-warning",errorBackground:"--g-color-base-danger-light",warningBackground:"--g-color-base-warning-light",mute:"--g-color-line-generic",stroke:"--g-color-text-hint",fill:"--g-color-base-generic-ultralight",nodeFill:"--g-color-base-float",nodeShadow:"--g-color-sfx-shadow",titleColor:"--g-color-text-primary",textColor:"--g-color-text-complementary",buttonBorderColor:"--g-color-line-generic",groupBorderColor:"--g-color-base-info-light-hover",groupFill:"--g-color-base-info-light",titleHoverColor:"--g-color-text-link-hover",nodeHover:"--g-color-base-float-hover",specialHover:"--g-color-line-brand"},t=getComputedStyle(document.body),i=Object.keys(e).reduce(((i,s)=>{const n=t.getPropertyValue(e[s]).replace(/ /g,"");return n&&(i[s]=n),i}),{});return Object.assign(Object.assign(Object.assign({},a),i),{getCommonColor:e=>t.getPropertyValue(`--g-color-${e}`).replace(/ /g,"")})}const w={linkType:"arrow"};function L(e=w){const t=e.colors||{};return Object.assign(Object.assign({initialTop:10,initialLeft:10},e),{colors:Object.assign(Object.assign(Object.assign({},a),y()),t)})}function R(e,t,i,s){const n=L(i);return new S(e,n,t,s)}var T=i(59284),x=(i(43781),i(62060),function(){if("undefined"!==typeof Map)return Map;function e(e,t){var i=-1;return e.some((function(e,s){return e[0]===t&&(i=s,!0)})),i}return function(){function t(){this.__entries__=[]}return Object.defineProperty(t.prototype,"size",{get:function(){return this.__entries__.length},enumerable:!0,configurable:!0}),t.prototype.get=function(t){var i=e(this.__entries__,t),s=this.__entries__[i];return s&&s[1]},t.prototype.set=function(t,i){var s=e(this.__entries__,t);~s?this.__entries__[s][1]=i:this.__entries__.push([t,i])},t.prototype.delete=function(t){var i=this.__entries__,s=e(i,t);~s&&i.splice(s,1)},t.prototype.has=function(t){return!!~e(this.__entries__,t)},t.prototype.clear=function(){this.__entries__.splice(0)},t.prototype.forEach=function(e,t){void 0===t&&(t=null);for(var i=0,s=this.__entries__;i0},e.prototype.connect_=function(){k&&!this.connected_&&(document.addEventListener("transitionend",this.onTransitionEnd_),window.addEventListener("resize",this.refresh),O?(this.mutationsObserver_=new MutationObserver(this.refresh),this.mutationsObserver_.observe(document,{attributes:!0,childList:!0,characterData:!0,subtree:!0})):(document.addEventListener("DOMSubtreeModified",this.refresh),this.mutationEventsAdded_=!0),this.connected_=!0)},e.prototype.disconnect_=function(){k&&this.connected_&&(document.removeEventListener("transitionend",this.onTransitionEnd_),window.removeEventListener("resize",this.refresh),this.mutationsObserver_&&this.mutationsObserver_.disconnect(),this.mutationEventsAdded_&&document.removeEventListener("DOMSubtreeModified",this.refresh),this.mutationsObserver_=null,this.mutationEventsAdded_=!1,this.connected_=!1)},e.prototype.onTransitionEnd_=function(e){var t=e.propertyName,i=void 0===t?"":t;I.some((function(e){return!!~i.indexOf(e)}))&&this.refresh()},e.getInstance=function(){return this.instance_||(this.instance_=new e),this.instance_},e.instance_=null,e}(),M=function(e,t){for(var i=0,s=Object.keys(t);i0},e}(),Y="undefined"!==typeof WeakMap?new WeakMap:new x,q=function e(t){if(!(this instanceof e))throw new TypeError("Cannot call a class as a function.");if(!arguments.length)throw new TypeError("1 argument required, but only 0 present.");var i=D.getInstance(),s=new K(t,i,this);Y.set(this,s)};["observe","unobserve","disconnect"].forEach((function(e){q.prototype[e]=function(){var t;return(t=Y.get(this))[e].apply(t,arguments)}}));"undefined"!==typeof A.ResizeObserver&&A.ResizeObserver;T.Component;T.Component;var $=i(87924),Q=i.n($);const X={width:280,expandedWidth:360,borderRadius:4,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:12,timeMaxWidth:25,percentageMaxWidth:25,textOffset:8,tagLeftOffset:4,tagTopOffset:5,statsOffset:24};class Z{constructor(e,t,i,s){this.top=0,this.left=0,this.canvas=e,this.stats=t,this.coords=i,this.colors=s,this.textProps={fontSize:X.textFontSize,lineHeight:X.textLineHeight,fontFamily:c,fill:null===s||void 0===s?void 0:s.titleColor},this.selectedGroup=t[0].group;const n=this.createTitles(),r=n.map((e=>e.getScaledHeight())),o=Math.max.apply(null,r);this.lineTop=this.top+o+X.textOffset;const a=this.createLine();this.content=this.createContent(n),this.group=this.createGroup(n,a,this.content),this.initListeners()}getCanvasObject(){return this.group}createTitles(){let e=this.left;return this.stats.map((({group:e})=>e)).map((t=>{var i,n;const r=new s.fabric.Text(t,Object.assign(Object.assign({left:e,top:this.top},this.textProps),{fill:t===this.selectedGroup?null===(i=this.colors)||void 0===i?void 0:i.titleColor:null===(n=this.colors)||void 0===n?void 0:n.textColor}));return e+=r.getScaledWidth()+X.statsOffset,r}))}createLine(){return new s.fabric.Path(`M ${this.left} ${this.lineTop}\n H ${X.expandedWidth-2*X.padding}`,{fill:"",stroke:this.colors.stroke,strokeWidth:1})}createContent(e){return this.stats.map((({group:t,stats:i},n)=>{const r=this.getContentItems(i,this.lineTop),o=e[n],a=o.left||0,l=a+o.getScaledWidth();return{group:t,items:new s.fabric.Group(r,{opacity:this.selectedGroup===t?1:0}),title:o,hoverLine:this.createHoverLine(a,l,t)}}))}getContentItems(e,t){let i=t+2*X.textOffset;const n=[],r=e=>{e.forEach((({name:e,value:t})=>{var r;const o=new s.fabric.Text(e,Object.assign({left:this.left,top:i},this.textProps)),a=X.expandedWidth/2-X.padding,l=X.expandedWidth-2*X.padding,c=new s.fabric.Textbox(String(t),Object.assign(Object.assign({left:a,top:i},this.textProps),{fill:null===(r=this.colors)||void 0===r?void 0:r.textColor,splitByGrapheme:!0,width:l-a}));n.push(o,c),i+=Math.max(o.getScaledHeight(),c.getScaledHeight())+X.textOffset}))};return!function(e){var t;return Boolean(null===(t=e[0])||void 0===t?void 0:t.items)}(e)?r(e):e.forEach((({name:t,items:o},a)=>{const l=new s.fabric.Text(t,Object.assign(Object.assign({left:this.left,top:i},this.textProps),{fontWeight:"bold"}));if(n.push(l),i+=l.getScaledHeight()+X.textOffset,r(o),a!==e.length-1){const e=new s.fabric.Path(`M ${this.left} ${i}\n H ${X.expandedWidth-2*X.padding}`,{fill:"",stroke:this.colors.stroke,strokeWidth:1,strokeDashArray:[6,4]});n.push(e),i+=e.getScaledHeight()+X.textOffset}})),n}createGroup(e,t,i){const n=i.map((({items:e})=>e)),r=i.map((({hoverLine:e})=>e));return new s.fabric.Group([...e,t,...n,...r],Object.assign({left:this.coords.left,top:this.coords.top},l))}createHoverLine(e,t,i){return new s.fabric.Path(`M ${e} ${this.lineTop-1}\n H ${t}`,{fill:"",stroke:this.colors.specialHover,strokeWidth:2,opacity:this.selectedGroup===i?1:0})}initListeners(){this.content.forEach((({group:e,title:t,items:i,hoverLine:s})=>{t.on("mousedown",(()=>{const n=this.selectedGroup,r=this.content.find((e=>e.group===n));r&&(r.title.set({fill:this.colors.textColor}),r.items.set({opacity:0}),r.hoverLine.set({opacity:0}),t.set({fill:this.colors.titleColor}),i.set({opacity:1}),s.set({opacity:1}),this.selectedGroup=e,this.canvas.requestRenderAll())}))}))}}function J(e,t,i,s,n){return new Z(e,t,{top:i,left:s},n).getCanvasObject()}function ee(e,t,i){return new s.fabric.Textbox(e?`#${e}`:"",{fontSize:12,lineHeight:14,textAlign:"right",fontFamily:c,fill:i.getCommonColor("text-secondary"),hoverCursor:t?"pointer":"default"})}const te={width:112,expandedWidth:360,borderRadius:6,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:16,textOffset:8},ie={scaleX:16/512,scaleY:16/512,originY:"center"};function se(e,t,i){const n=new s.fabric.Text(e,{fontSize:te.textFontSize,lineHeight:te.textFontSize,fontFamily:c,fill:i.getCommonColor("text-misc"),originY:"center"}),r=[n];let o;switch(e){case"Merge":o=new s.fabric.Path("M232.5 5.171C247.4-1.718 264.6-1.718 279.5 5.171L498.1 106.2C506.6 110.1 512 118.6 512 127.1C512 137.3 506.6 145.8 498.1 149.8L279.5 250.8C264.6 257.7 247.4 257.7 232.5 250.8L13.93 149.8C5.438 145.8 0 137.3 0 127.1C0 118.6 5.437 110.1 13.93 106.2L232.5 5.171zM498.1 234.2C506.6 238.1 512 246.6 512 255.1C512 265.3 506.6 273.8 498.1 277.8L279.5 378.8C264.6 385.7 247.4 385.7 232.5 378.8L13.93 277.8C5.438 273.8 0 265.3 0 255.1C0 246.6 5.437 238.1 13.93 234.2L67.13 209.6L219.1 279.8C242.5 290.7 269.5 290.7 292.9 279.8L444.9 209.6L498.1 234.2zM292.9 407.8L444.9 337.6L498.1 362.2C506.6 366.1 512 374.6 512 383.1C512 393.3 506.6 401.8 498.1 405.8L279.5 506.8C264.6 513.7 247.4 513.7 232.5 506.8L13.93 405.8C5.438 401.8 0 393.3 0 383.1C0 374.6 5.437 366.1 13.93 362.2L67.13 337.6L219.1 407.8C242.5 418.7 269.5 418.7 292.9 407.8V407.8z",ie);break;case"UnionAll":o=new s.fabric.Path("M200 288H88c-21.4 0-32.1 25.8-17 41l32.9 31-99.2 99.3c-6.2 6.2-6.2 16.4 0 22.6l25.4 25.4c6.2 6.2 16.4 6.2 22.6 0L152 408l31.1 33c15.1 15.1 40.9 4.4 40.9-17V312c0-13.3-10.7-24-24-24zm112-64h112c21.4 0 32.1-25.9 17-41l-33-31 99.3-99.3c6.2-6.2 6.2-16.4 0-22.6L481.9 4.7c-6.2-6.2-16.4-6.2-22.6 0L360 104l-31.1-33C313.8 55.9 288 66.6 288 88v112c0 13.3 10.7 24 24 24zm96 136l33-31.1c15.1-15.1 4.4-40.9-17-40.9H312c-13.3 0-24 10.7-24 24v112c0 21.4 25.9 32.1 41 17l31-32.9 99.3 99.3c6.2 6.2 16.4 6.2 22.6 0l25.4-25.4c6.2-6.2 6.2-16.4 0-22.6L408 360zM183 71.1L152 104 52.7 4.7c-6.2-6.2-16.4-6.2-22.6 0L4.7 30.1c-6.2 6.2-6.2 16.4 0 22.6L104 152l-33 31.1C55.9 198.2 66.6 224 88 224h112c13.3 0 24-10.7 24-24V88c0-21.3-25.9-32-41-16.9z",ie);break;case"HashShuffle":o=new s.fabric.Path("M504.971 359.029c9.373 9.373 9.373 24.569 0 33.941l-80 79.984c-15.01 15.01-40.971 4.49-40.971-16.971V416h-58.785a12.004 12.004 0 0 1-8.773-3.812l-70.556-75.596 53.333-57.143L352 336h32v-39.981c0-21.438 25.943-31.998 40.971-16.971l80 79.981zM12 176h84l52.781 56.551 53.333-57.143-70.556-75.596A11.999 11.999 0 0 0 122.785 96H12c-6.627 0-12 5.373-12 12v56c0 6.627 5.373 12 12 12zm372 0v39.984c0 21.46 25.961 31.98 40.971 16.971l80-79.984c9.373-9.373 9.373-24.569 0-33.941l-80-79.981C409.943 24.021 384 34.582 384 56.019V96h-58.785a12.004 12.004 0 0 0-8.773 3.812L96 336H12c-6.627 0-12 5.373-12 12v56c0 6.627 5.373 12 12 12h110.785c3.326 0 6.503-1.381 8.773-3.812L352 176h32z",ie);break;case"Map":o=new s.fabric.Path("M256 8c137 0 248 111 248 248S393 504 256 504 8 393 8 256 119 8 256 8zm-28.9 143.6l75.5 72.4H120c-13.3 0-24 10.7-24 24v16c0 13.3 10.7 24 24 24h182.6l-75.5 72.4c-9.7 9.3-9.9 24.8-.4 34.3l11 10.9c9.4 9.4 24.6 9.4 33.9 0L404.3 273c9.4-9.4 9.4-24.6 0-33.9L271.6 106.3c-9.4-9.4-24.6-9.4-33.9 0l-11 10.9c-9.5 9.6-9.3 25.1.4 34.4z",ie);break;case"Broadcast":o=new s.fabric.Path("M377.941 169.941V216H134.059v-46.059c0-21.382-25.851-32.09-40.971-16.971L7.029 239.029c-9.373 9.373-9.373 24.568 0 33.941l86.059 86.059c15.119 15.119 40.971 4.411 40.971-16.971V296h243.882v46.059c0 21.382 25.851 32.09 40.971 16.971l86.059-86.059c9.373-9.373 9.373-24.568 0-33.941l-86.059-86.059c-15.119-15.12-40.971-4.412-40.971 16.97z",ie)}return o&&(o.set({fill:i.getCommonColor("text-misc"),top:0,left:0,originY:"center"}),n.set({left:22}),r.push(o)),new s.fabric.Group(r,Object.assign(Object.assign({},l),{hoverCursor:t?"pointer":"default"}))}class ne{constructor(e,t,i,s,n){this.expanded=!1,this.expandedNodeHeight=0,this.nodeHeight=0,this.canvas=e,this.coords=t,this.treeNode=i,this.opts=s,this.em=n,this.data=Q()(i,["data","data"]),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup(),this.initListeners()}getShape(){return this.group}getFillColor(){return this.opts.colors.getCommonColor("base-misc-light")}getHoverFillColor(){return this.opts.colors.getCommonColor("base-misc-light-hover")}getShadow(){}getHoverShadow(){}toggleHighlight(e){this.isExpandable()&&!this.expanded&&this.body.set({fill:e?this.getHoverFillColor():this.getFillColor()}),this.canvas.requestRenderAll()}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+te.padding,new s.fabric.Rect({width:te.width,height:this.nodeHeight,fill:this.getFillColor(),shadow:this.getShadow(),stroke:e.getCommonColor("line-misc"),rx:te.borderRadius,ry:te.borderRadius,hoverCursor:this.isExpandable()?"pointer":"default"})}prepareShapeObjects(){return[ee(this.data.id,this.isExpandable(),this.opts.colors),se(this.data.name||"",this.isExpandable(),this.opts.colors)]}setShapeObjectsCoords(){const[e,t]=this.objects,i=te.padding,s=this.expanded?te.expandedWidth:te.width,n=t.getScaledWidth();e.set({left:0,top:4,width:s-4}),t.set({left:s/2-n/2,top:i})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},l))}initListeners(){this.initHover(),this.isExpandable()&&this.initExpand()}initHover(){this.group.on("mouseover",(()=>{this.em.dispatch("node:mouseover",this.treeNode),this.toggleHighlight(!0)})),this.group.on("mouseout",(()=>{this.em.dispatch("node:mouseout",this.treeNode),this.toggleHighlight(!1)}))}initExpand(){this.group.on("mousedown",(e=>{var t;this.stats&&(null===(t=e.subTargets)||void 0===t?void 0:t.includes(this.stats))||(this.expanded=!this.expanded,this.updateDimensions(),this.em.dispatch("node:resize",this.treeNode))}))}updateDimensions(){const e=this.opts.colors,[t,i]=this.objects,s=i.getScaledWidth();let n,r;this.expanded?(this.stats=J(this.canvas,this.data.stats,(this.group.top||0)+this.body.getScaledHeight()+te.padding,(this.group.left||0)+te.padding,e),this.expandedNodeHeight=this.nodeHeight+this.stats.getScaledHeight()+2*te.padding,n=te.expandedWidth,r=this.expandedNodeHeight,this.group.addWithUpdate(this.stats)):(n=te.width,r=this.nodeHeight,this.group.removeWithUpdate(this.stats),this.stats=void 0);const o=function(e,t){const i=[];return t.forEachObject((s=>{i.push(s),t.removeWithUpdate(s),e.add(s)})),()=>{i.forEach((i=>{e.remove(i),t.addWithUpdate(i)}))}}(this.canvas,this.group);this.body.set({width:n,height:r,fill:this.getFillColor(),shadow:this.getShadow()}),t.set({width:n-4}),i.set({left:(this.body.left||0)+(this.body.width||0)/2-s/2}),o()}isExpandable(){return Boolean(this.data.stats&&this.data.stats.length>0)}}const re={width:190,bevelSize:10,titleFontSize:h,titleLineHeight:d,padding:12};class oe{constructor(e,t,i,n,r){this.nodeHeight=0,this.coords=t,this.opts=n,this.data=Q()(i,["data","data"]),this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(){}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+re.padding,new s.fabric.Polygon([{x:re.bevelSize,y:0},{x:re.width-re.bevelSize,y:0},{x:re.width,y:re.bevelSize},{x:re.width,y:this.nodeHeight-re.bevelSize},{x:re.width-re.bevelSize,y:this.nodeHeight},{x:re.bevelSize,y:this.nodeHeight},{x:0,y:this.nodeHeight-re.bevelSize},{x:0,y:re.bevelSize}],{fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,shadow:this.getShadow(),hoverCursor:"default"})}prepareShapeObjects(){var e,t;return[(e=[this.data.name||""],t=this.opts.colors,new s.fabric.Text(e.join("\n"),{fontSize:re.titleFontSize,lineHeight:re.titleLineHeight,left:0,top:26,fontFamily:c,fontStyle:"italic",fill:t.getCommonColor("text-primary")}))]}setShapeObjectsCoords(){const[e]=this.objects,t=re.padding,i=e.getScaledWidth();e.set({left:re.width/2-i/2,top:t})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},l))}}const ae=40,le=40,ce=20;class he{constructor(e,t,i,n,r){this.coords=t,this.opts=n,this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.body=this.prepareNodeBody(),this.group=this.createGroup()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(){}prepareNodeBody(){const e=this.opts.colors;return new s.fabric.Rect({width:ae,height:le,fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,rx:ce,ry:ce,shadow:this.getShadow(),hoverCursor:"default"})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body],Object.assign({top:e,left:t},l))}}const de={width:112,borderRadius:6,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:12,textOffset:8};class ue{constructor(e,t,i,n,r){this.nodeHeight=0,this.coords=t,this.opts=n,this.data=Q()(i,["data","data"]),this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(){}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+de.padding,new s.fabric.Rect({width:de.width,height:this.nodeHeight,fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,shadow:this.getShadow(),hoverCursor:"default"})}prepareShapeObjects(){var e,t;return[(e=[this.data.name||""],t=this.opts.colors,new s.fabric.Text(e.join("\n"),{fontSize:de.textFontSize,lineHeight:de.textLineHeight,left:0,top:26,fontFamily:c,fill:t.getCommonColor("text-primary")}))]}setShapeObjectsCoords(){const[e]=this.objects,t=de.padding,i=e.getScaledWidth();e.set({left:de.width/2-i/2,top:t})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},l))}}const ge={width:248,expandedWidth:360,borderRadius:6,titleFontSize:h,titleLineHeight:d,textFontSize:h,textLineHeight:d,padding:12,textOffset:8};class pe{constructor(e,t,i,n,r){this.expanded=!1,this.expandedNodeHeight=0,this.nodeHeight=0,this.canvas=e,this.coords=t,this.treeNode=i,this.opts=n,this.em=r,this.data=Q()(i,["data","data"]),this.shadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:1,blur:5}),this.hoverShadow=new s.fabric.Shadow({color:n.colors.nodeShadow,offsetY:3,blur:8}),this.objects=this.prepareShapeObjects(),this.setShapeObjectsCoords(),this.body=this.prepareNodeBody(),this.group=this.createGroup(),this.initListeners()}getShape(){return this.group}getFillColor(){return this.opts.colors.nodeFill}getHoverFillColor(){return this.opts.colors.nodeHover}getShadow(){return this.shadow}getHoverShadow(){return this.hoverShadow}toggleHighlight(e){this.isExpandable()&&!this.expanded&&this.body.set({fill:e?this.getHoverFillColor():this.getFillColor(),shadow:e?this.getHoverShadow():this.getShadow()}),this.canvas.requestRenderAll()}prepareNodeBody(){const e=this.opts.colors,t=this.objects[this.objects.length-1];return this.nodeHeight=(t.top||0)+t.getScaledHeight()+ge.padding,new s.fabric.Rect({width:ge.width,height:this.nodeHeight,fill:this.getFillColor(),stroke:null===e||void 0===e?void 0:e.nodeShadow,rx:ge.borderRadius,ry:ge.borderRadius,shadow:this.getShadow(),hoverCursor:this.isExpandable()?"pointer":"default"})}prepareShapeObjects(){const e=ee(this.data.id,this.isExpandable(),this.opts.colors),t=(i=this.data.operators||[this.data.name||""],n=this.isExpandable(),r=this.opts.colors,new s.fabric.Text(i.join("\n"),{fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:c,fill:r.getCommonColor("text-primary"),hoverCursor:n?"pointer":"default"}));var i,n,r;const o=function(e,t){if(0===e.length)return new s.fabric.Group([],Object.assign({top:0,left:0},l));const i=new s.fabric.Text("Tables:",{fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:c,fill:t.getCommonColor("text-secondary"),hoverCursor:"pointer"}),n=i.getScaledWidth()+2,r=ge.width-2*ge.padding-n,o=new s.fabric.Textbox(e.join("\n"),{left:n,width:r,fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:c,fill:t.getCommonColor("text-primary"),splitByGrapheme:!0,hoverCursor:"pointer"});return new s.fabric.Group([i,o],Object.assign({top:0,left:0},l))}(this.data.tables||[],this.opts.colors),a=function(e,t){if(!e)return new s.fabric.Group([],Object.assign({top:0,left:0},l));const i=new s.fabric.Text("CTE:",{fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:c,fill:t.getCommonColor("text-secondary"),hoverCursor:"pointer"}),n=i.getScaledWidth()+2,r=ge.width-2*ge.padding-n,o=new s.fabric.Textbox(e,{left:n,width:r,fontSize:ge.textFontSize,lineHeight:ge.textLineHeight,fontFamily:c,fill:t.getCommonColor("text-primary"),splitByGrapheme:!0,hoverCursor:"pointer"});return new s.fabric.Group([i,o],Object.assign({top:0,left:0},l))}(this.data.cte||"",this.opts.colors);return[e,t,o,a]}setShapeObjectsCoords(){const[e,t,i,s]=this.objects;let n=ge.padding;const r=ge.padding;e.set({left:0,top:4,width:(this.expanded?ge.expandedWidth:ge.width)-4}),t.set({left:r,top:n}),n+=t.getScaledHeight(),i.set({left:r,top:n+(0===i.size()?0:ge.textOffset)}),n+=i.getScaledHeight(),s.set({left:r,top:n+(0===s.size()?0:ge.textOffset)})}createGroup(){const{top:e,left:t}=this.coords;return new s.fabric.Group([this.body,...this.objects],Object.assign({top:e,left:t},l))}initListeners(){this.initHover(),this.isExpandable()&&this.initExpand()}initHover(){this.group.on("mouseover",(()=>{this.em.dispatch("node:mouseover",this.treeNode),this.toggleHighlight(!0)})),this.group.on("mouseout",(()=>{this.em.dispatch("node:mouseout",this.treeNode),this.toggleHighlight(!1)}))}initExpand(){this.group.on("mousedown",(e=>{var t;this.stats&&(null===(t=e.subTargets)||void 0===t?void 0:t.includes(this.stats))||(this.updateDimensions(),this.expanded=!this.expanded,this.em.dispatch("node:resize",this.treeNode))}))}updateDimensions(){const e=this.opts.colors;if(this.expanded){const e=ge.width,t=this.nodeHeight;this.body.set({width:e,height:t,fill:this.getFillColor(),shadow:this.getShadow()}).setCoords(),this.objects[0].set({width:e-4}).setCoords(),this.group.removeWithUpdate(this.stats),this.stats=void 0}else{this.stats=J(this.canvas,this.data.stats,(this.group.top||0)+this.body.getScaledHeight()+ge.padding,(this.group.left||0)+ge.padding,e),this.expandedNodeHeight=this.nodeHeight+this.stats.getScaledHeight()+2*ge.padding;const t=ge.expandedWidth,i=this.expandedNodeHeight;this.body.set({width:t,height:i,fill:this.getFillColor(),shadow:this.getShadow()}).setCoords(),this.objects[0].set({width:t-4}).setCoords(),this.group.addWithUpdate(this.stats)}}isExpandable(){return Boolean(this.data.stats&&this.data.stats.length>0)}}function me(e,t,i,s,n){return function(e){const t=Q()(e,["data","data"]);return"connection"===(null===t||void 0===t?void 0:t.type)}(i)?new ne(e,t,i,s,n):function(e){const t=Q()(e,["data","data"]);return"result"===(null===t||void 0===t?void 0:t.type)}(i)?new ue(e,t,i,s,n):function(e){const t=Q()(e,["data","data"]);return"query"===(null===t||void 0===t?void 0:t.type)}(i)?new he(e,t,i,s,n):function(e){const t=Q()(e,["data","data"]);return"materialize"===(null===t||void 0===t?void 0:t.type)}(i)?new oe(e,t,i,s,n):new pe(e,t,i,s,n)}},55299:(e,t,i)=>{"use strict";i.d(t,{F:()=>O});var s=i(59284),n=i(81240),r=i(84476),o=i(80604),a=i(99991),l=i(63365),c=i(46423),h=i(87184);const d=s.createContext(null),u=()=>{const e=s.useContext(d);if(!e)throw new Error('Alert: `useAlertContext` hook is used out of "AlertContext"');return e},g=e=>{const{view:t}=u();return s.createElement(r.$,Object.assign({view:"filled"===t?"normal-contrast":void 0},e))};var p=i(69220);const m=(0,p.om)("alert"),f=({layout:e,view:t,children:i})=>s.createElement(d.Provider,{value:{layout:e,view:t}},i);var _=i(18677),v=i(10800),C=i(45720),b=i(43937);const E=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",fillRule:"evenodd",d:"M8 15A7 7 0 1 0 8 1a7 7 0 0 0 0 14m3.1-8.55a.75.75 0 1 0-1.2-.9L7.419 8.858 6.03 7.47a.75.75 0 0 0-1.06 1.06l2 2a.75.75 0 0 0 1.13-.08z",clipRule:"evenodd"}));var S=i(70825),y=i(71153),w=i(94420);const L=e=>s.createElement("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",width:16,height:16,fill:"none",viewBox:"0 0 16 16"},e),s.createElement("path",{fill:"currentColor",d:"m14.61 6.914-7.632 8.08a1.614 1.614 0 0 1-2.69-1.66L5.5 10H2.677A1.677 1.677 0 0 1 1.12 7.7l2.323-5.807A2.22 2.22 0 0 1 5.5.5h4c.968 0 1.637.967 1.298 1.873L10 4.5h3.569a1.431 1.431 0 0 1 1.04 2.414"}));var R=i(27612);const T={danger:{filled:_.A,outlined:v.A},info:{filled:C.A,outlined:b.A},success:{filled:E,outlined:S.A},warning:{filled:y.A,outlined:w.A},utility:{filled:L,outlined:R.A},normal:null};var x=i(98089);var k=i(72837);const A=JSON.parse('{"label_close":"Close"}'),N=JSON.parse('{"label_close":"\u0417\u0430\u043a\u0440\u044b\u0442\u044c"}'),I=(0,k.N)({en:A,ru:N},"Alert"),O=e=>{const{theme:t="normal",view:i="filled",layout:d="vertical",message:u,className:g,corners:p,style:_,onClose:v,align:C,qa:b}=e;return s.createElement(f,{layout:d,view:i},s.createElement(o.Z,{style:_,className:m({corners:p},(0,c.Y)({py:4,px:5},g)),theme:t,view:i,qa:b},s.createElement(h.s,{gap:"3",alignItems:C},"undefined"===typeof e.icon?s.createElement(O.Icon,{theme:t,view:i}):e.icon,s.createElement(h.s,{direction:"vertical"===d?"column":"row",gap:"5",grow:!0},s.createElement(h.s,{gap:"2",grow:!0,className:m("text-content")},s.createElement(h.s,{direction:"column",gap:"1",grow:!0,justifyContent:C},"string"===typeof e.title?s.createElement(O.Title,{text:e.title}):e.title,u)),Array.isArray(e.actions)?s.createElement(O.Actions,{items:e.actions}):e.actions),v&&s.createElement(r.$,{view:"flat",className:m("close-btn"),onClick:v,extraProps:{"aria-label":I("label_close")}},s.createElement(a.I,{data:n.A,size:18,className:(0,l.$)({color:"secondary"})})))))};O.Icon=({className:e,theme:t,view:i="filled",size:n=18})=>{const r=T[t];if(!r)return null;let o;return"success"===t?o="positive":"normal"!==t&&(o=t),s.createElement("div",{className:m("icon",(0,l.$)({color:o},e))},s.createElement(a.I,{data:r[i],size:n}))},O.Title=({text:e,className:t})=>s.createElement(x.E,{variant:"subheader-2",className:m("title",t)},e),O.Actions=({items:e,children:t,className:i})=>{const{layout:n}=u();return s.createElement(h.s,{className:m("actions",{minContent:"horizontal"===n},i),direction:"row",gap:"3",wrap:!0,alignItems:"horizontal"===n?"center":"flex-start"},(null===e||void 0===e?void 0:e.map((({handler:e,text:t},i)=>s.createElement(g,{key:i,onClick:e},t))))||t)},O.Action=g},80604:(e,t,i)=>{"use strict";i.d(t,{Z:()=>l});var s=i(27145),n=i(59284),r=i(46734),o=i(9296);const a=(0,i(69220).om)("card"),l=n.forwardRef((function(e,t){const{type:i="container",theme:l,view:c,size:h="m",children:d,className:u,onClick:g,disabled:p,selected:m}=e,f=(0,s.Tt)(e,["type","theme","view","size","children","className","onClick","disabled","selected"]),_="selection"===i,v="container"===i,C=("action"===i||_)&&Boolean(g)&&!p,b=v?"normal":void 0,E=v||_?"outlined":void 0,S=C?g:void 0,{onKeyDown:y}=(0,r.N)(g);return n.createElement(o.a,Object.assign({ref:t,role:C?"button":void 0,className:a({theme:l||b,view:c||E,type:i,selected:m,size:h,disabled:p,clickable:C},u),onClick:S,onKeyDown:C?y:void 0,tabIndex:C?0:void 0},f),d)}))},80953:(e,t,i)=>{"use strict";i.d(t,{t:()=>r});var s=i(59284);const n=(0,i(69220).om)("spin"),r=s.forwardRef((function(e,t){const{size:i="m",style:r,className:o,qa:a}=e;return s.createElement("div",{ref:t,style:r,className:n({size:i},o),"data-qa":a},s.createElement("div",{className:n("inner")}))}))},1155:(e,t,i)=>{"use strict";i.d(t,{m:()=>u});var s=i(59284),n=i(32084),r=i(81517),o=i(39238),a=i(98089),l=i(69220),c=i(7412);const h=(0,l.om)("tooltip"),d=["bottom","top"],u=e=>{const{children:t,content:i,disabled:l,placement:u=d,qa:g,id:p,className:m,style:f,disablePortal:_,contentClassName:v,openDelay:C=1e3,closeDelay:b}=e,[E,S]=s.useState(null),y=(0,r.d)(E,{openDelay:C,closeDelay:b,preventTriggerOnFocus:!0}),w=s.Children.only(t),L=(0,c.Q)(w),R=(0,n.N)(S,L);return s.createElement(s.Fragment,null,s.cloneElement(w,{ref:R}),E?s.createElement(o.z,{id:p,role:"tooltip",className:h(null,m),style:f,open:y&&!l,placement:u,anchorRef:{current:E},disablePortal:_,disableEscapeKeyDown:!0,disableOutsideClick:!0,disableLayer:!0,qa:g},s.createElement("div",{className:h("content",v)},s.createElement(a.E,{variant:"body-short",color:"complementary"},i))):null)}},70206:(e,t)=>{var i;i=function(e){e.version="1.2.2";var t=function(){for(var e=0,t=new Array(256),i=0;256!=i;++i)e=1&(e=1&(e=1&(e=1&(e=1&(e=1&(e=1&(e=1&(e=i)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1)?-306674912^e>>>1:e>>>1,t[i]=e;return"undefined"!==typeof Int32Array?new Int32Array(t):t}(),i=function(e){var t=0,i=0,s=0,n="undefined"!==typeof Int32Array?new Int32Array(4096):new Array(4096);for(s=0;256!=s;++s)n[s]=e[s];for(s=0;256!=s;++s)for(i=e[s],t=256+s;t<4096;t+=256)i=n[t]=i>>>8^e[255&i];var r=[];for(s=1;16!=s;++s)r[s-1]="undefined"!==typeof Int32Array?n.subarray(256*s,256*s+256):n.slice(256*s,256*s+256);return r}(t),s=i[0],n=i[1],r=i[2],o=i[3],a=i[4],l=i[5],c=i[6],h=i[7],d=i[8],u=i[9],g=i[10],p=i[11],m=i[12],f=i[13],_=i[14];e.table=t,e.bstr=function(e,i){for(var s=~i,n=0,r=e.length;n>>8^t[255&(s^e.charCodeAt(n++))];return~s},e.buf=function(e,i){for(var v=~i,C=e.length-15,b=0;b>8&255]^m[e[b++]^v>>16&255]^p[e[b++]^v>>>24]^g[e[b++]]^u[e[b++]]^d[e[b++]]^h[e[b++]]^c[e[b++]]^l[e[b++]]^a[e[b++]]^o[e[b++]]^r[e[b++]]^n[e[b++]]^s[e[b++]]^t[e[b++]];for(C+=15;b>>8^t[255&(v^e[b++])];return~v},e.str=function(e,i){for(var s=~i,n=0,r=e.length,o=0,a=0;n>>8^t[255&(s^o)]:o<2048?s=(s=s>>>8^t[255&(s^(192|o>>6&31))])>>>8^t[255&(s^(128|63&o))]:o>=55296&&o<57344?(o=64+(1023&o),a=1023&e.charCodeAt(n++),s=(s=(s=(s=s>>>8^t[255&(s^(240|o>>8&7))])>>>8^t[255&(s^(128|o>>2&63))])>>>8^t[255&(s^(128|a>>6&15|(3&o)<<4))])>>>8^t[255&(s^(128|63&a))]):s=(s=(s=s>>>8^t[255&(s^(224|o>>12&15))])>>>8^t[255&(s^(128|o>>6&63))])>>>8^t[255&(s^(128|63&o))];return~s}},"undefined"===typeof DO_NOT_EXPORT_CRC?i(t):i({})},22868:(e,t,i)=>{"use strict";var s=i(67796),n={};function r(e,t,i,s,n,r,o,a){if(!e){var l;if(void 0===t)l=new Error("Minified exception occurred; use the non-minified dev environment for the full error message and additional helpful warnings.");else{var c=[i,s,n,r,o,a],h=0;(l=new Error(t.replace(/%s/g,(function(){return c[h++]})))).name="Invariant Violation"}throw l.framesToPop=1,l}}var o="mixins";e.exports=function(e,t,i){var a=[],l={mixins:"DEFINE_MANY",statics:"DEFINE_MANY",propTypes:"DEFINE_MANY",contextTypes:"DEFINE_MANY",childContextTypes:"DEFINE_MANY",getDefaultProps:"DEFINE_MANY_MERGED",getInitialState:"DEFINE_MANY_MERGED",getChildContext:"DEFINE_MANY_MERGED",render:"DEFINE_ONCE",componentWillMount:"DEFINE_MANY",componentDidMount:"DEFINE_MANY",componentWillReceiveProps:"DEFINE_MANY",shouldComponentUpdate:"DEFINE_ONCE",componentWillUpdate:"DEFINE_MANY",componentDidUpdate:"DEFINE_MANY",componentWillUnmount:"DEFINE_MANY",UNSAFE_componentWillMount:"DEFINE_MANY",UNSAFE_componentWillReceiveProps:"DEFINE_MANY",UNSAFE_componentWillUpdate:"DEFINE_MANY",updateComponent:"OVERRIDE_BASE"},c={getDerivedStateFromProps:"DEFINE_MANY_MERGED"},h={displayName:function(e,t){e.displayName=t},mixins:function(e,t){if(t)for(var i=0;i{"use strict";var s=i(59284),n=i(22868);if("undefined"===typeof s)throw Error("create-react-class could not find the React object. If you are using script tags, make sure that React is being loaded before create-react-class.");var r=(new s.Component).updater;e.exports=n(s.Component,s.isValidElement,r)},91740:e=>{e.exports=Date.now||function(){return(new Date).getTime()}},41470:(e,t,i)=>{var s=i(91740);e.exports=function(e,t,i){var n,r,o,a,l;function c(){var h=s()-a;h0?n=setTimeout(c,t-h):(n=null,i||(l=e.apply(o,r),n||(o=r=null)))}return null==t&&(t=100),function(){o=this,r=arguments,a=s();var h=i&&!n;return n||(n=setTimeout(c,t)),h&&(l=e.apply(o,r),o=r=null),l}}},7252:(e,t,i)=>{var s,n=n||{version:"5.4.2"};if(t.fabric=n,"undefined"!==typeof document&&"undefined"!==typeof window)document instanceof("undefined"!==typeof HTMLDocument?HTMLDocument:Document)?n.document=document:n.document=document.implementation.createHTMLDocument(""),n.window=window;else{var r=new(i(66574).JSDOM)(decodeURIComponent("%3C!DOCTYPE%20html%3E%3Chtml%3E%3Chead%3E%3C%2Fhead%3E%3Cbody%3E%3C%2Fbody%3E%3C%2Fhtml%3E"),{features:{FetchExternalResources:["img"]},resources:"usable"}).window;n.document=r.document,n.jsdomImplForWrapper=i(2748).implForWrapper,n.nodeCanvas=i(52246).Canvas,n.window=r,DOMParser=n.window.DOMParser}function o(e,t){var i=e.canvas,s=t.targetCanvas,n=s.getContext("2d");n.translate(0,s.height),n.scale(1,-1);var r=i.height-s.height;n.drawImage(i,0,r,s.width,s.height,0,0,s.width,s.height)}function a(e,t){var i=t.targetCanvas.getContext("2d"),s=t.destinationWidth,n=t.destinationHeight,r=s*n*4,o=new Uint8Array(this.imageBuffer,0,r),a=new Uint8ClampedArray(this.imageBuffer,0,r);e.readPixels(0,0,s,n,e.RGBA,e.UNSIGNED_BYTE,o);var l=new ImageData(a,s,n);i.putImageData(l,0,0)}n.isTouchSupported="ontouchstart"in n.window||"ontouchstart"in n.document||n.window&&n.window.navigator&&n.window.navigator.maxTouchPoints>0,n.isLikelyNode="undefined"!==typeof Buffer&&"undefined"===typeof window,n.SHARED_ATTRIBUTES=["display","transform","fill","fill-opacity","fill-rule","opacity","stroke","stroke-dasharray","stroke-linecap","stroke-dashoffset","stroke-linejoin","stroke-miterlimit","stroke-opacity","stroke-width","id","paint-order","vector-effect","instantiated_by_use","clip-path"],n.DPI=96,n.reNum="(?:[-+]?(?:\\d+|\\d*\\.\\d+)(?:[eE][-+]?\\d+)?)",n.commaWsp="(?:\\s+,?\\s*|,\\s*)",n.rePathCommand=/([-+]?((\d+\.\d+)|((\d+)|(\.\d+)))(?:[eE][-+]?\d+)?)/gi,n.reNonWord=/[ \n\.,;!\?\-]/,n.fontPaths={},n.iMatrix=[1,0,0,1,0,0],n.svgNS="http://www.w3.org/2000/svg",n.perfLimitSizeTotal=2097152,n.maxCacheSideLimit=4096,n.minCacheSideLimit=256,n.charWidthsCache={},n.textureSize=2048,n.disableStyleCopyPaste=!1,n.enableGLFiltering=!0,n.devicePixelRatio=n.window.devicePixelRatio||n.window.webkitDevicePixelRatio||n.window.mozDevicePixelRatio||1,n.browserShadowBlurConstant=1,n.arcToSegmentsCache={},n.boundsOfCurveCache={},n.cachesBoundsOfCurve=!0,n.forceGLPutImageData=!1,n.initFilterBackend=function(){return n.enableGLFiltering&&n.isWebglSupported&&n.isWebglSupported(n.textureSize)?(console.log("max texture size: "+n.maxTextureSize),new n.WebglFilterBackend({tileSize:n.textureSize})):n.Canvas2dFilterBackend?new n.Canvas2dFilterBackend:void 0},"undefined"!==typeof document&&"undefined"!==typeof window&&(window.fabric=n),function(){function e(e,t){if(this.__eventListeners[e]){var i=this.__eventListeners[e];t?i[i.indexOf(t)]=!1:n.util.array.fill(i,!1)}}function t(e,t){var i=function(){t.apply(this,arguments),this.off(e,i)}.bind(this);this.on(e,i)}n.Observable={fire:function(e,t){if(!this.__eventListeners)return this;var i=this.__eventListeners[e];if(!i)return this;for(var s=0,n=i.length;s-1||!!t&&this._objects.some((function(t){return"function"===typeof t.contains&&t.contains(e,!0)}))},complexity:function(){return this._objects.reduce((function(e,t){return e+=t.complexity?t.complexity():0}),0)}},n.CommonMethods={_setOptions:function(e){for(var t in e)this.set(t,e[t])},_initGradient:function(e,t){!e||!e.colorStops||e instanceof n.Gradient||this.set(t,new n.Gradient(e))},_initPattern:function(e,t,i){!e||!e.source||e instanceof n.Pattern?i&&i():this.set(t,new n.Pattern(e,i))},_setObject:function(e){for(var t in e)this._set(t,e[t])},set:function(e,t){return"object"===typeof e?this._setObject(e):this._set(e,t),this},_set:function(e,t){this[e]=t},toggle:function(e){var t=this.get(e);return"boolean"===typeof t&&this.set(e,!t),this},get:function(e){return this[e]}},function(e){var t=Math.sqrt,i=Math.atan2,s=Math.pow,r=Math.PI/180,o=Math.PI/2;n.util={cos:function(e){if(0===e)return 1;switch(e<0&&(e=-e),e/o){case 1:case 3:return 0;case 2:return-1}return Math.cos(e)},sin:function(e){if(0===e)return 0;var t=1;switch(e<0&&(t=-1),e/o){case 1:return t;case 2:return 0;case 3:return-t}return Math.sin(e)},removeFromArray:function(e,t){var i=e.indexOf(t);return-1!==i&&e.splice(i,1),e},getRandomInt:function(e,t){return Math.floor(Math.random()*(t-e+1))+e},degreesToRadians:function(e){return e*r},radiansToDegrees:function(e){return e/r},rotatePoint:function(e,t,i){var s=new n.Point(e.x-t.x,e.y-t.y),r=n.util.rotateVector(s,i);return new n.Point(r.x,r.y).addEquals(t)},rotateVector:function(e,t){var i=n.util.sin(t),s=n.util.cos(t);return{x:e.x*s-e.y*i,y:e.x*i+e.y*s}},createVector:function(e,t){return new n.Point(t.x-e.x,t.y-e.y)},calcAngleBetweenVectors:function(e,t){return Math.acos((e.x*t.x+e.y*t.y)/(Math.hypot(e.x,e.y)*Math.hypot(t.x,t.y)))},getHatVector:function(e){return new n.Point(e.x,e.y).multiply(1/Math.hypot(e.x,e.y))},getBisector:function(e,t,i){var s=n.util.createVector(e,t),r=n.util.createVector(e,i),o=n.util.calcAngleBetweenVectors(s,r),a=o*(0===n.util.calcAngleBetweenVectors(n.util.rotateVector(s,o),r)?1:-1)/2;return{vector:n.util.getHatVector(n.util.rotateVector(s,a)),angle:o}},projectStrokeOnPoints:function(e,t,i){var s=[],r=t.strokeWidth/2,o=t.strokeUniform?new n.Point(1/t.scaleX,1/t.scaleY):new n.Point(1,1),a=function(e){var t=r/Math.hypot(e.x,e.y);return new n.Point(e.x*t*o.x,e.y*t*o.y)};return e.length<=1||e.forEach((function(l,c){var h,d,u=new n.Point(l.x,l.y);0===c?(d=e[c+1],h=i?a(n.util.createVector(d,u)).addEquals(u):e[e.length-1]):c===e.length-1?(h=e[c-1],d=i?a(n.util.createVector(h,u)).addEquals(u):e[0]):(h=e[c-1],d=e[c+1]);var g,p,m=n.util.getBisector(u,h,d),f=m.vector,_=m.angle;if("miter"===t.strokeLineJoin&&(g=-r/Math.sin(_/2),p=new n.Point(f.x*g*o.x,f.y*g*o.y),Math.hypot(p.x,p.y)/r<=t.strokeMiterLimit))return s.push(u.add(p)),void s.push(u.subtract(p));g=-r*Math.SQRT2,p=new n.Point(f.x*g*o.x,f.y*g*o.y),s.push(u.add(p)),s.push(u.subtract(p))})),s},transformPoint:function(e,t,i){return i?new n.Point(t[0]*e.x+t[2]*e.y,t[1]*e.x+t[3]*e.y):new n.Point(t[0]*e.x+t[2]*e.y+t[4],t[1]*e.x+t[3]*e.y+t[5])},makeBoundingBoxFromPoints:function(e,t){if(t)for(var i=0;i0&&(t>s?t-=s:t=0,i>s?i-=s:i=0);var n,r=!0,o=e.getImageData(t,i,2*s||1,2*s||1),a=o.data.length;for(n=3;n0)n.util.hasStyleChanged(r,c,!0)?o.push({start:s,end:s+1,style:c}):o[o.length-1].end++;r=c||{}}else s+=i[a].length;return o},stylesFromArray:function(e,t){if(!Array.isArray(e))return e;for(var i=t.split("\n"),s=-1,n=0,r={},o=0;o=n?r-n:2*Math.PI-(n-r)}function o(e,t,i){for(var o=i[1],a=i[2],l=i[3],c=i[4],h=i[5],d=function(e,t,i,o,a,l,c){var h=Math.PI,d=c*h/180,u=n.util.sin(d),g=n.util.cos(d),p=0,m=0,f=-g*e*.5-u*t*.5,_=-g*t*.5+u*e*.5,v=(i=Math.abs(i))*i,C=(o=Math.abs(o))*o,b=_*_,E=f*f,S=v*C-v*b-C*E,y=0;if(S<0){var w=Math.sqrt(1-S/(v*C));i*=w,o*=w}else y=(a===l?-1:1)*Math.sqrt(S/(v*b+C*E));var L=y*i*_/o,R=-y*o*f/i,T=g*L-u*R+.5*e,x=u*L+g*R+.5*t,k=r(1,0,(f-L)/i,(_-R)/o),A=r((f-L)/i,(_-R)/o,(-f-L)/i,(-_-R)/o);0===l&&A>0?A-=2*h:1===l&&A<0&&(A+=2*h);for(var N=Math.ceil(Math.abs(A/h*2)),I=[],O=A/N,D=8/3*Math.sin(O/4)*Math.sin(O/4)/Math.sin(O/2),M=k+O,P=0;P1e-4;)i=l(r),n=r,(s=a(c.x,c.y,i.x,i.y))+o>t?(r-=h,h/=2):(c=i,r+=h,o+=s);return i.angle=d(n),i}function p(e){for(var t,i,s,n,r=0,o=e.length,g=0,p=0,m=0,f=0,_=[],v=0;vy)for(var L=1,R=f.length;L2;for(t=t||0,h&&(l=e[2].xe[i-2].x?1:r.x===e[i-2].x?0:-1,c=r.y>e[i-2].y?1:r.y===e[i-2].y?0:-1),s.push(["L",r.x+l*t,r.y+c*t]),s},n.util.getPathSegmentsInfo=p,n.util.getBoundsOfCurve=function(t,i,s,r,o,a,l,c){var h;if(n.cachesBoundsOfCurve&&(h=e.call(arguments),n.boundsOfCurveCache[h]))return n.boundsOfCurveCache[h];var d,u,g,p,m,f,_,v,C=Math.sqrt,b=Math.min,E=Math.max,S=Math.abs,y=[],w=[[],[]];u=6*t-12*s+6*o,d=-3*t+9*s-9*o+3*l,g=3*s-3*t;for(var L=0;L<2;++L)if(L>0&&(u=6*i-12*r+6*a,d=-3*i+9*r-9*a+3*c,g=3*r-3*i),S(d)<1e-12){if(S(u)<1e-12)continue;0<(p=-g/u)&&p<1&&y.push(p)}else(_=u*u-4*g*d)<0||(0<(m=(-u+(v=C(_)))/(2*d))&&m<1&&y.push(m),0<(f=(-u-v)/(2*d))&&f<1&&y.push(f));for(var R,T,x,k=y.length,A=k;k--;)R=(x=1-(p=y[k]))*x*x*t+3*x*x*p*s+3*x*p*p*o+p*p*p*l,w[0][k]=R,T=x*x*x*i+3*x*x*p*r+3*x*p*p*a+p*p*p*c,w[1][k]=T;w[0][A]=t,w[1][A]=i,w[0][A+1]=l,w[1][A+1]=c;var N=[{x:b.apply(null,w[0]),y:b.apply(null,w[1])},{x:E.apply(null,w[0]),y:E.apply(null,w[1])}];return n.cachesBoundsOfCurve&&(n.boundsOfCurveCache[h]=N),N},n.util.getPointOnPath=function(e,t,i){i||(i=p(e));for(var s=0;t-i[s].length>0&&s=t}))}}}(),function(){function e(t,i,s){if(s)if(!n.isLikelyNode&&i instanceof Element)t=i;else if(i instanceof Array){t=[];for(var r=0,o=i.length;r57343)return e.charAt(t);if(55296<=i&&i<=56319){if(e.length<=t+1)throw"High surrogate without following low surrogate";var s=e.charCodeAt(t+1);if(56320>s||s>57343)throw"High surrogate without following low surrogate";return e.charAt(t)+e.charAt(t+1)}if(0===t)throw"Low surrogate without preceding high surrogate";var n=e.charCodeAt(t-1);if(55296>n||n>56319)throw"Low surrogate without preceding high surrogate";return!1}n.util.string={camelize:function(e){return e.replace(/-+(.)?/g,(function(e,t){return t?t.toUpperCase():""}))},capitalize:function(e,t){return e.charAt(0).toUpperCase()+(t?e.slice(1):e.slice(1).toLowerCase())},escapeXml:function(e){return e.replace(/&/g,"&").replace(/"/g,""").replace(/'/g,"'").replace(//g,">")},graphemeSplit:function(t){var i,s=0,n=[];for(s=0;s-1?e.prototype[n]=function(e){return function(){var i=this.constructor.superclass;this.constructor.superclass=s;var n=t[e].apply(this,arguments);if(this.constructor.superclass=i,"initialize"!==e)return n}}(n):e.prototype[n]=t[n],i&&(t.toString!==Object.prototype.toString&&(e.prototype.toString=t.toString),t.valueOf!==Object.prototype.valueOf&&(e.prototype.valueOf=t.valueOf))};function r(){}function o(t){for(var i=null,s=this;s.constructor.superclass;){var n=s.constructor.superclass.prototype[t];if(s[t]!==n){i=n;break}s=s.constructor.superclass.prototype}return i?arguments.length>1?i.apply(this,e.call(arguments,1)):i.call(this):console.log("tried to callSuper "+t+", method not found in prototype chain",this)}n.util.createClass=function(){var i=null,n=e.call(arguments,0);function a(){this.initialize.apply(this,arguments)}"function"===typeof n[0]&&(i=n.shift()),a.superclass=i,a.subclasses=[],i&&(r.prototype=i.prototype,a.prototype=new r,i.subclasses.push(a));for(var l=0,c=n.length;l-1||"touch"===e.pointerType}}(),function(){var e=n.document.createElement("div"),t="string"===typeof e.style.opacity,i="string"===typeof e.style.filter,s=/alpha\s*\(\s*opacity\s*=\s*([^\)]+)\)/,r=function(e){return e};t?r=function(e,t){return e.style.opacity=t,e}:i&&(r=function(e,t){var i=e.style;return e.currentStyle&&!e.currentStyle.hasLayout&&(i.zoom=1),s.test(i.filter)?(t=t>=.9999?"":"alpha(opacity="+100*t+")",i.filter=i.filter.replace(s,t)):i.filter+=" alpha(opacity="+100*t+")",e}),n.util.setStyle=function(e,t){var i=e.style;if(!i)return e;if("string"===typeof t)return e.style.cssText+=";"+t,t.indexOf("opacity")>-1?r(e,t.match(/opacity:\s*(\d?\.?\d*)/)[1]):e;for(var s in t)if("opacity"===s)r(e,t[s]);else{var n="float"===s||"cssFloat"===s?"undefined"===typeof i.styleFloat?"cssFloat":"styleFloat":s;i.setProperty(n,t[s])}return e}}(),function(){var e=Array.prototype.slice;var t,i,s=function(t){return e.call(t,0)};try{t=s(n.document.childNodes)instanceof Array}catch(a){}function r(e,t){var i=n.document.createElement(e);for(var s in t)"class"===s?i.className=t[s]:"for"===s?i.htmlFor=t[s]:i.setAttribute(s,t[s]);return i}function o(e){for(var t=0,i=0,s=n.document.documentElement,r=n.document.body||{scrollLeft:0,scrollTop:0};e&&(e.parentNode||e.host)&&((e=e.parentNode||e.host)===n.document?(t=r.scrollLeft||s.scrollLeft||0,i=r.scrollTop||s.scrollTop||0):(t+=e.scrollLeft||0,i+=e.scrollTop||0),1!==e.nodeType||"fixed"!==e.style.position););return{left:t,top:i}}t||(s=function(e){for(var t=new Array(e.length),i=e.length;i--;)t[i]=e[i];return t}),i=n.document.defaultView&&n.document.defaultView.getComputedStyle?function(e,t){var i=n.document.defaultView.getComputedStyle(e,null);return i?i[t]:void 0}:function(e,t){var i=e.style[t];return!i&&e.currentStyle&&(i=e.currentStyle[t]),i},function(){var e=n.document.documentElement.style,t="userSelect"in e?"userSelect":"MozUserSelect"in e?"MozUserSelect":"WebkitUserSelect"in e?"WebkitUserSelect":"KhtmlUserSelect"in e?"KhtmlUserSelect":"";n.util.makeElementUnselectable=function(e){return"undefined"!==typeof e.onselectstart&&(e.onselectstart=n.util.falseFunction),t?e.style[t]="none":"string"===typeof e.unselectable&&(e.unselectable="on"),e},n.util.makeElementSelectable=function(e){return"undefined"!==typeof e.onselectstart&&(e.onselectstart=null),t?e.style[t]="":"string"===typeof e.unselectable&&(e.unselectable=""),e}}(),n.util.setImageSmoothing=function(e,t){e.imageSmoothingEnabled=e.imageSmoothingEnabled||e.webkitImageSmoothingEnabled||e.mozImageSmoothingEnabled||e.msImageSmoothingEnabled||e.oImageSmoothingEnabled,e.imageSmoothingEnabled=t},n.util.getById=function(e){return"string"===typeof e?n.document.getElementById(e):e},n.util.toArray=s,n.util.addClass=function(e,t){e&&-1===(" "+e.className+" ").indexOf(" "+t+" ")&&(e.className+=(e.className?" ":"")+t)},n.util.makeElement=r,n.util.wrapElement=function(e,t,i){return"string"===typeof t&&(t=r(t,i)),e.parentNode&&e.parentNode.replaceChild(t,e),t.appendChild(e),t},n.util.getScrollLeftTop=o,n.util.getElementOffset=function(e){var t,s,n=e&&e.ownerDocument,r={left:0,top:0},a={left:0,top:0},l={borderLeftWidth:"left",borderTopWidth:"top",paddingLeft:"left",paddingTop:"top"};if(!n)return a;for(var c in l)a[l[c]]+=parseInt(i(e,c),10)||0;return t=n.documentElement,"undefined"!==typeof e.getBoundingClientRect&&(r=e.getBoundingClientRect()),s=o(e),{left:r.left+s.left-(t.clientLeft||0)+a.left,top:r.top+s.top-(t.clientTop||0)+a.top}},n.util.getNodeCanvas=function(e){var t=n.jsdomImplForWrapper(e);return t._canvas||t._image},n.util.cleanUpJsdomNode=function(e){if(n.isLikelyNode){var t=n.jsdomImplForWrapper(e);t&&(t._image=null,t._canvas=null,t._currentSrc=null,t._attributes=null,t._classList=null)}}}(),function(){function e(){}n.util.request=function(t,i){i||(i={});var s=i.method?i.method.toUpperCase():"GET",r=i.onComplete||function(){},o=new n.window.XMLHttpRequest,a=i.body||i.parameters;return o.onreadystatechange=function(){4===o.readyState&&(r(o),o.onreadystatechange=e)},"GET"===s&&(a=null,"string"===typeof i.parameters&&(t=function(e,t){return e+(/\?/.test(e)?"&":"?")+t}(t,i.parameters))),o.open(s,t,!0),"POST"!==s&&"PUT"!==s||o.setRequestHeader("Content-Type","application/x-www-form-urlencoded"),o.send(a),o}}(),n.log=console.log,n.warn=console.warn,function(){var e=n.util.object.extend,t=n.util.object.clone,i=[];function s(){return!1}function r(e,t,i,s){return-i*Math.cos(e/s*(Math.PI/2))+i+t}n.util.object.extend(i,{cancelAll:function(){var e=this.splice(0);return e.forEach((function(e){e.cancel()})),e},cancelByCanvas:function(e){if(!e)return[];var t=this.filter((function(t){return"object"===typeof t.target&&t.target.canvas===e}));return t.forEach((function(e){e.cancel()})),t},cancelByTarget:function(e){var t=this.findAnimationsByTarget(e);return t.forEach((function(e){e.cancel()})),t},findAnimationIndex:function(e){return this.indexOf(this.findAnimation(e))},findAnimation:function(e){return this.find((function(t){return t.cancel===e}))},findAnimationsByTarget:function(e){return e?this.filter((function(t){return t.target===e})):[]}});var o=n.window.requestAnimationFrame||n.window.webkitRequestAnimationFrame||n.window.mozRequestAnimationFrame||n.window.oRequestAnimationFrame||n.window.msRequestAnimationFrame||function(e){return n.window.setTimeout(e,1e3/60)},a=n.window.cancelAnimationFrame||n.window.clearTimeout;function l(){return o.apply(n.window,arguments)}n.util.animate=function(i){i||(i={});var o,a=!1,c=function(){var e=n.runningAnimations.indexOf(o);return e>-1&&n.runningAnimations.splice(e,1)[0]};return o=e(t(i),{cancel:function(){return a=!0,c()},currentValue:"startValue"in i?i.startValue:0,completionRate:0,durationRate:0}),n.runningAnimations.push(o),l((function(e){var t,n=e||+new Date,h=i.duration||500,d=n+h,u=i.onChange||s,g=i.abort||s,p=i.onComplete||s,m=i.easing||r,f="startValue"in i&&i.startValue.length>0,_="startValue"in i?i.startValue:0,v="endValue"in i?i.endValue:100,C=i.byValue||(f?_.map((function(e,t){return v[t]-_[t]})):v-_);i.onStart&&i.onStart(),function e(i){var s=(t=i||+new Date)>d?h:t-n,r=s/h,b=f?_.map((function(e,t){return m(s,_[t],C[t],h)})):m(s,_,C,h),E=f?Math.abs((b[0]-_[0])/C[0]):Math.abs((b-_)/C);if(o.currentValue=f?b.slice():b,o.completionRate=E,o.durationRate=r,!a){if(!g(b,E,r))return t>d?(o.currentValue=f?v.slice():v,o.completionRate=1,o.durationRate=1,u(f?v.slice():v,1,1),p(v,1,1),void c()):(u(b,E,r),void l(e));c()}}(n)})),o.cancel},n.util.requestAnimFrame=l,n.util.cancelAnimFrame=function(){return a.apply(n.window,arguments)},n.runningAnimations=i}(),function(){function e(e,t,i){var s="rgba("+parseInt(e[0]+i*(t[0]-e[0]),10)+","+parseInt(e[1]+i*(t[1]-e[1]),10)+","+parseInt(e[2]+i*(t[2]-e[2]),10);return s+=","+(e&&t?parseFloat(e[3]+i*(t[3]-e[3])):1),s+=")"}n.util.animateColor=function(t,i,s,r){var o=new n.Color(t).getSource(),a=new n.Color(i).getSource(),l=r.onComplete,c=r.onChange;return r=r||{},n.util.animate(n.util.object.extend(r,{duration:s||500,startValue:o,endValue:a,byValue:a,easing:function(t,i,s,n){return e(i,s,r.colorEasing?r.colorEasing(t,n):1-Math.cos(t/n*(Math.PI/2)))},onComplete:function(t,i,s){if(l)return l(e(a,a,0),i,s)},onChange:function(t,i,s){if(c){if(Array.isArray(t))return c(e(t,t,0),i,s);c(t,i,s)}}}))}}(),function(){function e(e,t,i,s){return e-1&&h>-1&&h-1)&&(i="stroke")}else{if("href"===e||"xlink:href"===e||"font"===e)return i;if("imageSmoothing"===e)return"optimizeQuality"===i;a=l?i.map(r):r(i,n)}}else i="";return!l&&isNaN(a)?i:a}function g(e){return new RegExp("^("+e.join("|")+")\\b","i")}function p(e,t){var i,s,n,r,o=[];for(n=0,r=t.length;n1;)l.shift(),c=t.util.multiplyTransformMatrices(c,l[0]);return c}}();var v=new RegExp("^\\s*("+t.reNum+"+)\\s*,?\\s*("+t.reNum+"+)\\s*,?\\s*("+t.reNum+"+)\\s*,?\\s*("+t.reNum+"+)\\s*$");function C(e){if(!t.svgViewBoxElementsRegEx.test(e.nodeName))return{};var i,s,n,o,a,l,c=e.getAttribute("viewBox"),h=1,d=1,u=e.getAttribute("width"),g=e.getAttribute("height"),p=e.getAttribute("x")||0,m=e.getAttribute("y")||0,f=e.getAttribute("preserveAspectRatio")||"",_=!c||!(c=c.match(v)),C=!u||!g||"100%"===u||"100%"===g,b=_&&C,E={},S="",y=0,w=0;if(E.width=0,E.height=0,E.toBeParsed=b,_&&(p||m)&&e.parentNode&&"#document"!==e.parentNode.nodeName&&(S=" translate("+r(p)+" "+r(m)+") ",a=(e.getAttribute("transform")||"")+S,e.setAttribute("transform",a),e.removeAttribute("x"),e.removeAttribute("y")),b)return E;if(_)return E.width=r(u),E.height=r(g),E;if(i=-parseFloat(c[1]),s=-parseFloat(c[2]),n=parseFloat(c[3]),o=parseFloat(c[4]),E.minX=i,E.minY=s,E.viewBoxWidth=n,E.viewBoxHeight=o,C?(E.width=n,E.height=o):(E.width=r(u),E.height=r(g),h=E.width/n,d=E.height/o),"none"!==(f=t.util.parsePreserveAspectRatioAttribute(f)).alignX&&("meet"===f.meetOrSlice&&(d=h=h>d?d:h),"slice"===f.meetOrSlice&&(d=h=h>d?h:d),y=E.width-n*h,w=E.height-o*h,"Mid"===f.alignX&&(y/=2),"Mid"===f.alignY&&(w/=2),"Min"===f.alignX&&(y=0),"Min"===f.alignY&&(w=0)),1===h&&1===d&&0===i&&0===s&&0===p&&0===m)return E;if((p||m)&&"#document"!==e.parentNode.nodeName&&(S=" translate("+r(p)+" "+r(m)+") "),a=S+" matrix("+h+" 0 0 "+d+" "+(i*h+y)+" "+(s*d+w)+") ","svg"===e.nodeName){for(l=e.ownerDocument.createElementNS(t.svgNS,"g");e.firstChild;)l.appendChild(e.firstChild);e.appendChild(l)}else(l=e).removeAttribute("x"),l.removeAttribute("y"),a=l.getAttribute("transform")+a;return l.setAttribute("transform",a),E}function b(e,t){var i="xlink:href",s=_(e,t.getAttribute(i).slice(1));if(s&&s.getAttribute(i)&&b(e,s),["gradientTransform","x1","x2","y1","y2","gradientUnits","cx","cy","r","fx","fy"].forEach((function(e){s&&!t.hasAttribute(e)&&s.hasAttribute(e)&&t.setAttribute(e,s.getAttribute(e))})),!t.children.length)for(var n=s.cloneNode(!0);n.firstChild;)t.appendChild(n.firstChild);t.removeAttribute(i)}t.parseSVGDocument=function(e,i,n,r){if(e){!function(e){for(var i=p(e,["use","svg:use"]),s=0;i.length&&se.x&&this.y>e.y},gte:function(e){return this.x>=e.x&&this.y>=e.y},lerp:function(e,t){return"undefined"===typeof t&&(t=.5),t=Math.max(Math.min(1,t),0),new i(this.x+(e.x-this.x)*t,this.y+(e.y-this.y)*t)},distanceFrom:function(e){var t=this.x-e.x,i=this.y-e.y;return Math.sqrt(t*t+i*i)},midPointFrom:function(e){return this.lerp(e)},min:function(e){return new i(Math.min(this.x,e.x),Math.min(this.y,e.y))},max:function(e){return new i(Math.max(this.x,e.x),Math.max(this.y,e.y))},toString:function(){return this.x+","+this.y},setXY:function(e,t){return this.x=e,this.y=t,this},setX:function(e){return this.x=e,this},setY:function(e){return this.y=e,this},setFromPoint:function(e){return this.x=e.x,this.y=e.y,this},swap:function(e){var t=this.x,i=this.y;this.x=e.x,this.y=e.y,e.x=t,e.y=i},clone:function(){return new i(this.x,this.y)}})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={});function i(e){this.status=e,this.points=[]}t.Intersection?t.warn("fabric.Intersection is already defined"):(t.Intersection=i,t.Intersection.prototype={constructor:i,appendPoint:function(e){return this.points.push(e),this},appendPoints:function(e){return this.points=this.points.concat(e),this}},t.Intersection.intersectLineLine=function(e,s,n,r){var o,a=(r.x-n.x)*(e.y-n.y)-(r.y-n.y)*(e.x-n.x),l=(s.x-e.x)*(e.y-n.y)-(s.y-e.y)*(e.x-n.x),c=(r.y-n.y)*(s.x-e.x)-(r.x-n.x)*(s.y-e.y);if(0!==c){var h=a/c,d=l/c;0<=h&&h<=1&&0<=d&&d<=1?(o=new i("Intersection")).appendPoint(new t.Point(e.x+h*(s.x-e.x),e.y+h*(s.y-e.y))):o=new i}else o=new i(0===a||0===l?"Coincident":"Parallel");return o},t.Intersection.intersectLinePolygon=function(e,t,s){var n,r,o,a,l=new i,c=s.length;for(a=0;a0&&(l.status="Intersection"),l},t.Intersection.intersectPolygonPolygon=function(e,t){var s,n=new i,r=e.length;for(s=0;s0&&(n.status="Intersection"),n},t.Intersection.intersectPolygonRectangle=function(e,s,n){var r=s.min(n),o=s.max(n),a=new t.Point(o.x,r.y),l=new t.Point(r.x,o.y),c=i.intersectLinePolygon(r,a,e),h=i.intersectLinePolygon(a,o,e),d=i.intersectLinePolygon(o,l,e),u=i.intersectLinePolygon(l,r,e),g=new i;return g.appendPoints(c.points),g.appendPoints(h.points),g.appendPoints(d.points),g.appendPoints(u.points),g.points.length>0&&(g.status="Intersection"),g})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={});function i(e){e?this._tryParsingColor(e):this.setSource([0,0,0,1])}function s(e,t,i){return i<0&&(i+=1),i>1&&(i-=1),i<1/6?e+6*(t-e)*i:i<.5?t:i<2/3?e+(t-e)*(2/3-i)*6:e}t.Color?t.warn("fabric.Color is already defined."):(t.Color=i,t.Color.prototype={_tryParsingColor:function(e){var t;e in i.colorNameMap&&(e=i.colorNameMap[e]),"transparent"===e&&(t=[255,255,255,0]),t||(t=i.sourceFromHex(e)),t||(t=i.sourceFromRgb(e)),t||(t=i.sourceFromHsl(e)),t||(t=[0,0,0,1]),t&&this.setSource(t)},_rgbToHsl:function(e,i,s){e/=255,i/=255,s/=255;var n,r,o,a=t.util.array.max([e,i,s]),l=t.util.array.min([e,i,s]);if(o=(a+l)/2,a===l)n=r=0;else{var c=a-l;switch(r=o>.5?c/(2-a-l):c/(a+l),a){case e:n=(i-s)/c+(i0)-(e<0)||+e};function g(e,t){var i=e.angle+d(Math.atan2(t.y,t.x))+360;return Math.round(i%360/45)}function p(e,i){var s=i.transform.target,n=s.canvas,r=t.util.object.clone(i);r.target=s,n&&n.fire("object:"+e,r),s.fire(e,i)}function m(e,t){var i=t.canvas,s=e[i.uniScaleKey];return i.uniformScaling&&!s||!i.uniformScaling&&s}function f(e){return e.originX===c&&e.originY===c}function _(e,t,i){var s=e.lockScalingX,n=e.lockScalingY;return!(!s||!n)||(!(t||!s&&!n||!i)||(!(!s||"x"!==t)||!(!n||"y"!==t)))}function v(e,t,i,s){return{e:e,transform:t,pointer:{x:i,y:s}}}function C(e){return function(t,i,s,n){var r=i.target,o=r.getCenterPoint(),a=r.translateToOriginPoint(o,i.originX,i.originY),l=e(t,i,s,n);return r.setPositionByOrigin(a,i.originX,i.originY),l}}function b(e,t){return function(i,s,n,r){var o=t(i,s,n,r);return o&&p(e,v(i,s,n,r)),o}}function E(e,i,s,n,r){var o=e.target,a=o.controls[e.corner],l=o.canvas.getZoom(),c=o.padding/l,h=o.toLocalPoint(new t.Point(n,r),i,s);return h.x>=c&&(h.x-=c),h.x<=-c&&(h.x+=c),h.y>=c&&(h.y-=c),h.y<=c&&(h.y+=c),h.x-=a.offsetX,h.y-=a.offsetY,h}function S(e){return e.flipX!==e.flipY}function y(e,t,i,s,n){if(0!==e[t]){var r=n/e._getTransformedDimensions()[s]*e[i];e.set(i,r)}}function w(e,t,i,s){var n,c=t.target,h=c._getTransformedDimensions(0,c.skewY),u=E(t,t.originX,t.originY,i,s),g=Math.abs(2*u.x)-h.x,p=c.skewX;g<2?n=0:(n=d(Math.atan2(g/c.scaleX,h.y/c.scaleY)),t.originX===r&&t.originY===l&&(n=-n),t.originX===a&&t.originY===o&&(n=-n),S(c)&&(n=-n));var m=p!==n;if(m){var f=c._getTransformedDimensions().y;c.set("skewX",n),y(c,"skewY","scaleY","y",f)}return m}function L(e,t,i,s){var n,c=t.target,h=c._getTransformedDimensions(c.skewX,0),u=E(t,t.originX,t.originY,i,s),g=Math.abs(2*u.y)-h.y,p=c.skewY;g<2?n=0:(n=d(Math.atan2(g/c.scaleY,h.x/c.scaleX)),t.originX===r&&t.originY===l&&(n=-n),t.originX===a&&t.originY===o&&(n=-n),S(c)&&(n=-n));var m=p!==n;if(m){var f=c._getTransformedDimensions().x;c.set("skewY",n),y(c,"skewX","scaleX","x",f)}return m}function R(e,t,i,s,n){n=n||{};var r,o,a,l,c,d,g=t.target,p=g.lockScalingX,v=g.lockScalingY,C=n.by,b=m(e,g),S=_(g,C,b),y=t.gestureScale;if(S)return!1;if(y)o=t.scaleX*y,a=t.scaleY*y;else{if(r=E(t,t.originX,t.originY,i,s),c="y"!==C?u(r.x):1,d="x"!==C?u(r.y):1,t.signX||(t.signX=c),t.signY||(t.signY=d),g.lockScalingFlip&&(t.signX!==c||t.signY!==d))return!1;if(l=g._getTransformedDimensions(),b&&!C){var w=Math.abs(r.x)+Math.abs(r.y),L=t.original,R=w/(Math.abs(l.x*L.scaleX/g.scaleX)+Math.abs(l.y*L.scaleY/g.scaleY));o=L.scaleX*R,a=L.scaleY*R}else o=Math.abs(r.x*g.scaleX/l.x),a=Math.abs(r.y*g.scaleY/l.y);f(t)&&(o*=2,a*=2),t.signX!==c&&"y"!==C&&(t.originX=h[t.originX],o*=-1,t.signX=c),t.signY!==d&&"x"!==C&&(t.originY=h[t.originY],a*=-1,t.signY=d)}var T=g.scaleX,x=g.scaleY;return C?("x"===C&&g.set("scaleX",o),"y"===C&&g.set("scaleY",a)):(!p&&g.set("scaleX",o),!v&&g.set("scaleY",a)),T!==g.scaleX||x!==g.scaleY}n.scaleCursorStyleHandler=function(e,t,s){var n=m(e,s),r="";if(0!==t.x&&0===t.y?r="x":0===t.x&&0!==t.y&&(r="y"),_(s,r,n))return"not-allowed";var o=g(s,t);return i[o]+"-resize"},n.skewCursorStyleHandler=function(e,t,i){var n="not-allowed";if(0!==t.x&&i.lockSkewingY)return n;if(0!==t.y&&i.lockSkewingX)return n;var r=g(i,t)%4;return s[r]+"-resize"},n.scaleSkewCursorStyleHandler=function(e,t,i){return e[i.canvas.altActionKey]?n.skewCursorStyleHandler(e,t,i):n.scaleCursorStyleHandler(e,t,i)},n.rotationWithSnapping=b("rotating",C((function(e,t,i,s){var n=t,r=n.target,o=r.translateToOriginPoint(r.getCenterPoint(),n.originX,n.originY);if(r.lockRotation)return!1;var a,l=Math.atan2(n.ey-o.y,n.ex-o.x),c=Math.atan2(s-o.y,i-o.x),h=d(c-l+n.theta);if(r.snapAngle>0){var u=r.snapAngle,g=r.snapThreshold||u,p=Math.ceil(h/u)*u,m=Math.floor(h/u)*u;Math.abs(h-m)0?r:a:(h>0&&(n=d===o?r:a),h<0&&(n=d===o?a:r),S(l)&&(n=n===r?a:r)),t.originX=n,b("skewing",C(w))(e,t,i,s))},n.skewHandlerY=function(e,t,i,s){var n,a=t.target,h=a.skewY,d=t.originX;return!a.lockSkewingY&&(0===h?n=E(t,c,c,i,s).y>0?o:l:(h>0&&(n=d===r?o:l),h<0&&(n=d===r?l:o),S(a)&&(n=n===o?l:o)),t.originY=n,b("skewing",C(L))(e,t,i,s))},n.dragHandler=function(e,t,i,s){var n=t.target,r=i-t.offsetX,o=s-t.offsetY,a=!n.get("lockMovementX")&&n.left!==r,l=!n.get("lockMovementY")&&n.top!==o;return a&&n.set("left",r),l&&n.set("top",o),(a||l)&&p("moving",v(e,t,i,s)),a||l},n.scaleOrSkewActionName=function(e,t,i){var s=e[i.canvas.altActionKey];return 0===t.x?s?"skewX":"scaleY":0===t.y?s?"skewY":"scaleX":void 0},n.rotationStyleHandler=function(e,t,i){return i.lockRotation?"not-allowed":t.cursorStyle},n.fireEvent=p,n.wrapWithFixedAnchor=C,n.wrapWithFireEvent=b,n.getLocalPoint=E,t.controlsUtils=n}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.degreesToRadians,s=t.controlsUtils;s.renderCircleControl=function(e,t,i,s,n){s=s||{};var r,o=this.sizeX||s.cornerSize||n.cornerSize,a=this.sizeY||s.cornerSize||n.cornerSize,l="undefined"!==typeof s.transparentCorners?s.transparentCorners:n.transparentCorners,c=l?"stroke":"fill",h=!l&&(s.cornerStrokeColor||n.cornerStrokeColor),d=t,u=i;e.save(),e.fillStyle=s.cornerColor||n.cornerColor,e.strokeStyle=s.cornerStrokeColor||n.cornerStrokeColor,o>a?(r=o,e.scale(1,a/o),u=i*o/a):a>o?(r=a,e.scale(o/a,1),d=t*a/o):r=o,e.lineWidth=1,e.beginPath(),e.arc(d,u,r/2,0,2*Math.PI,!1),e[c](),h&&e.stroke(),e.restore()},s.renderSquareControl=function(e,t,s,n,r){n=n||{};var o=this.sizeX||n.cornerSize||r.cornerSize,a=this.sizeY||n.cornerSize||r.cornerSize,l="undefined"!==typeof n.transparentCorners?n.transparentCorners:r.transparentCorners,c=l?"stroke":"fill",h=!l&&(n.cornerStrokeColor||r.cornerStrokeColor),d=o/2,u=a/2;e.save(),e.fillStyle=n.cornerColor||r.cornerColor,e.strokeStyle=n.cornerStrokeColor||r.cornerStrokeColor,e.lineWidth=1,e.translate(t,s),e.rotate(i(r.angle)),e[c+"Rect"](-d,-u,o,a),h&&e.strokeRect(-d,-u,o,a),e.restore()}}(t),function(e){"use strict";var t=e.fabric||(e.fabric={});t.Control=function(e){for(var t in e)this[t]=e[t]},t.Control.prototype={visible:!0,actionName:"scale",angle:0,x:0,y:0,offsetX:0,offsetY:0,sizeX:null,sizeY:null,touchSizeX:null,touchSizeY:null,cursorStyle:"crosshair",withConnection:!1,actionHandler:function(){},mouseDownHandler:function(){},mouseUpHandler:function(){},getActionHandler:function(){return this.actionHandler},getMouseDownHandler:function(){return this.mouseDownHandler},getMouseUpHandler:function(){return this.mouseUpHandler},cursorStyleHandler:function(e,t){return t.cursorStyle},getActionName:function(e,t){return t.actionName},getVisibility:function(e,t){var i=e._controlsVisibility;return i&&"undefined"!==typeof i[t]?i[t]:this.visible},setVisibility:function(e){this.visible=e},positionHandler:function(e,i){return t.util.transformPoint({x:this.x*e.x+this.offsetX,y:this.y*e.y+this.offsetY},i)},calcCornerCoords:function(e,i,s,n,r){var o,a,l,c,h=r?this.touchSizeX:this.sizeX,d=r?this.touchSizeY:this.sizeY;if(h&&d&&h!==d){var u=Math.atan2(d,h),g=Math.sqrt(h*h+d*d)/2,p=u-t.util.degreesToRadians(e),m=Math.PI/2-u-t.util.degreesToRadians(e);o=g*t.util.cos(p),a=g*t.util.sin(p),l=g*t.util.cos(m),c=g*t.util.sin(m)}else{g=.7071067812*(h&&d?h:i);p=t.util.degreesToRadians(45-e);o=l=g*t.util.cos(p),a=c=g*t.util.sin(p)}return{tl:{x:s-c,y:n-l},tr:{x:s+o,y:n-a},bl:{x:s-o,y:n+a},br:{x:s+c,y:n+l}}},render:function(e,i,s,n,r){if("circle"===((n=n||{}).cornerStyle||r.cornerStyle))t.controlsUtils.renderCircleControl.call(this,e,i,s,n,r);else t.controlsUtils.renderSquareControl.call(this,e,i,s,n,r)}}}(t),function(){function e(e,t){var i,s,r,o,a=e.getAttribute("style"),l=e.getAttribute("offset")||0;if(l=(l=parseFloat(l)/(/%$/.test(l)?100:1))<0?0:l>1?1:l,a){var c=a.split(/\s*;\s*/);for(""===c[c.length-1]&&c.pop(),o=c.length;o--;){var h=c[o].split(/\s*:\s*/),d=h[0].trim(),u=h[1].trim();"stop-color"===d?i=u:"stop-opacity"===d&&(r=u)}}return i||(i=e.getAttribute("stop-color")||"rgb(0,0,0)"),r||(r=e.getAttribute("stop-opacity")),s=(i=new n.Color(i)).getAlpha(),r=isNaN(parseFloat(r))?1:parseFloat(r),r*=s*t,{offset:l,color:i.toRgb(),opacity:r}}var t=n.util.object.clone;n.Gradient=n.util.createClass({offsetX:0,offsetY:0,gradientTransform:null,gradientUnits:"pixels",type:"linear",initialize:function(e){e||(e={}),e.coords||(e.coords={});var t,i=this;Object.keys(e).forEach((function(t){i[t]=e[t]})),this.id?this.id+="_"+n.Object.__uid++:this.id=n.Object.__uid++,t={x1:e.coords.x1||0,y1:e.coords.y1||0,x2:e.coords.x2||0,y2:e.coords.y2||0},"radial"===this.type&&(t.r1=e.coords.r1||0,t.r2=e.coords.r2||0),this.coords=t,this.colorStops=e.colorStops.slice()},addColorStop:function(e){for(var t in e){var i=new n.Color(e[t]);this.colorStops.push({offset:parseFloat(t),color:i.toRgb(),opacity:i.getAlpha()})}return this},toObject:function(e){var t={type:this.type,coords:this.coords,colorStops:this.colorStops,offsetX:this.offsetX,offsetY:this.offsetY,gradientUnits:this.gradientUnits,gradientTransform:this.gradientTransform?this.gradientTransform.concat():this.gradientTransform};return n.util.populateWithProperties(this,t,e),t},toSVG:function(e,i){var s,r,o,a,l=t(this.coords,!0),c=(i=i||{},t(this.colorStops,!0)),h=l.r1>l.r2,d=this.gradientTransform?this.gradientTransform.concat():n.iMatrix.concat(),u=-this.offsetX,g=-this.offsetY,p=!!i.additionalTransform,m="pixels"===this.gradientUnits?"userSpaceOnUse":"objectBoundingBox";if(c.sort((function(e,t){return e.offset-t.offset})),"objectBoundingBox"===m?(u/=e.width,g/=e.height):(u+=e.width/2,g+=e.height/2),"path"===e.type&&"percentage"!==this.gradientUnits&&(u-=e.pathOffset.x,g-=e.pathOffset.y),d[4]-=u,d[5]-=g,a='id="SVGID_'+this.id+'" gradientUnits="'+m+'"',a+=' gradientTransform="'+(p?i.additionalTransform+" ":"")+n.util.matrixToSVG(d)+'" ',"linear"===this.type?o=["\n']:"radial"===this.type&&(o=["\n']),"radial"===this.type){if(h)for((c=c.concat()).reverse(),s=0,r=c.length;s0){var _=f/Math.max(l.r1,l.r2);for(s=0,r=c.length;s\n')}return o.push("linear"===this.type?"\n":"\n"),o.join("")},toLive:function(e){var t,i,s,r=n.util.object.clone(this.coords);if(this.type){for("linear"===this.type?t=e.createLinearGradient(r.x1,r.y1,r.x2,r.y2):"radial"===this.type&&(t=e.createRadialGradient(r.x1,r.y1,r.r1,r.x2,r.y2,r.r2)),i=0,s=this.colorStops.length;i1?1:o,isNaN(o)&&(o=1);var a,l,c,h,d=t.getElementsByTagName("stop"),u="userSpaceOnUse"===t.getAttribute("gradientUnits")?"pixels":"percentage",g=t.getAttribute("gradientTransform")||"",p=[],m=0,f=0;for("linearGradient"===t.nodeName||"LINEARGRADIENT"===t.nodeName?(a="linear",l=function(e){return{x1:e.getAttribute("x1")||0,y1:e.getAttribute("y1")||0,x2:e.getAttribute("x2")||"100%",y2:e.getAttribute("y2")||0}}(t)):(a="radial",l=function(e){return{x1:e.getAttribute("fx")||e.getAttribute("cx")||"50%",y1:e.getAttribute("fy")||e.getAttribute("cy")||"50%",r1:0,x2:e.getAttribute("cx")||"50%",y2:e.getAttribute("cy")||"50%",r2:e.getAttribute("r")||"50%"}}(t)),c=d.length;c--;)p.push(e(d[c],o));return h=n.parseTransformAttribute(g),function(e,t,i,s){var n,r;Object.keys(t).forEach((function(e){"Infinity"===(n=t[e])?r=1:"-Infinity"===n?r=0:(r=parseFloat(t[e],10),"string"===typeof n&&/^(\d+\.\d+)%|(\d+)%$/.test(n)&&(r*=.01,"pixels"===s&&("x1"!==e&&"x2"!==e&&"r2"!==e||(r*=i.viewBoxWidth||i.width),"y1"!==e&&"y2"!==e||(r*=i.viewBoxHeight||i.height)))),t[e]=r}))}(0,l,r,u),"pixels"===u&&(m=-i.left,f=-i.top),new n.Gradient({id:t.getAttribute("id"),type:a,coords:l,colorStops:p,gradientUnits:u,gradientTransform:h,offsetX:m,offsetY:f})}})}(),function(){"use strict";var e=n.util.toFixed;n.Pattern=n.util.createClass({repeat:"repeat",offsetX:0,offsetY:0,crossOrigin:"",patternTransform:null,initialize:function(e,t){if(e||(e={}),this.id=n.Object.__uid++,this.setOptions(e),!e.source||e.source&&"string"!==typeof e.source)t&&t(this);else{var i=this;this.source=n.util.createImage(),n.util.loadImage(e.source,(function(e,s){i.source=e,t&&t(i,s)}),null,this.crossOrigin)}},toObject:function(t){var i,s,r=n.Object.NUM_FRACTION_DIGITS;return"string"===typeof this.source.src?i=this.source.src:"object"===typeof this.source&&this.source.toDataURL&&(i=this.source.toDataURL()),s={type:"pattern",source:i,repeat:this.repeat,crossOrigin:this.crossOrigin,offsetX:e(this.offsetX,r),offsetY:e(this.offsetY,r),patternTransform:this.patternTransform?this.patternTransform.concat():null},n.util.populateWithProperties(this,s,t),s},toSVG:function(e){var t="function"===typeof this.source?this.source():this.source,i=t.width/e.width,s=t.height/e.height,n=this.offsetX/e.width,r=this.offsetY/e.height,o="";return"repeat-x"!==this.repeat&&"no-repeat"!==this.repeat||(s=1,r&&(s+=Math.abs(r))),"repeat-y"!==this.repeat&&"no-repeat"!==this.repeat||(i=1,n&&(i+=Math.abs(n))),t.src?o=t.src:t.toDataURL&&(o=t.toDataURL()),'\n\n\n'},setOptions:function(e){for(var t in e)this[t]=e[t]},toLive:function(e){var t=this.source;if(!t)return"";if("undefined"!==typeof t.src){if(!t.complete)return"";if(0===t.naturalWidth||0===t.naturalHeight)return""}return e.createPattern(t,this.repeat)}})}(),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.toFixed;t.Shadow?t.warn("fabric.Shadow is already defined."):(t.Shadow=t.util.createClass({color:"rgb(0,0,0)",blur:0,offsetX:0,offsetY:0,affectStroke:!1,includeDefaultValues:!0,nonScaling:!1,initialize:function(e){for(var i in"string"===typeof e&&(e=this._parseShadow(e)),e)this[i]=e[i];this.id=t.Object.__uid++},_parseShadow:function(e){var i=e.trim(),s=t.Shadow.reOffsetsAndBlur.exec(i)||[];return{color:(i.replace(t.Shadow.reOffsetsAndBlur,"")||"rgb(0,0,0)").trim(),offsetX:parseFloat(s[1],10)||0,offsetY:parseFloat(s[2],10)||0,blur:parseFloat(s[3],10)||0}},toString:function(){return[this.offsetX,this.offsetY,this.blur,this.color].join("px ")},toSVG:function(e){var s=40,n=40,r=t.Object.NUM_FRACTION_DIGITS,o=t.util.rotateVector({x:this.offsetX,y:this.offsetY},t.util.degreesToRadians(-e.angle)),a=new t.Color(this.color);return e.width&&e.height&&(s=100*i((Math.abs(o.x)+this.blur)/e.width,r)+20,n=100*i((Math.abs(o.y)+this.blur)/e.height,r)+20),e.flipX&&(o.x*=-1),e.flipY&&(o.y*=-1),'\n\t\n\t\n\t\n\t\n\t\n\t\t\n\t\t\n\t\n\n'},toObject:function(){if(this.includeDefaultValues)return{color:this.color,blur:this.blur,offsetX:this.offsetX,offsetY:this.offsetY,affectStroke:this.affectStroke,nonScaling:this.nonScaling};var e={},i=t.Shadow.prototype;return["color","blur","offsetX","offsetY","affectStroke","nonScaling"].forEach((function(t){this[t]!==i[t]&&(e[t]=this[t])}),this),e}}),t.Shadow.reOffsetsAndBlur=/(?:\s|^)(-?\d+(?:\.\d*)?(?:px)?(?:\s?|$))?(-?\d+(?:\.\d*)?(?:px)?(?:\s?|$))?(\d+(?:\.\d*)?(?:px)?)?(?:\s?|$)(?:$|\s)/)}(t),function(){"use strict";if(n.StaticCanvas)n.warn("fabric.StaticCanvas is already defined.");else{var e=n.util.object.extend,t=n.util.getElementOffset,i=n.util.removeFromArray,s=n.util.toFixed,r=n.util.transformPoint,o=n.util.invertTransform,a=n.util.getNodeCanvas,l=n.util.createCanvasElement,c=new Error("Could not initialize `canvas` element");n.StaticCanvas=n.util.createClass(n.CommonMethods,{initialize:function(e,t){t||(t={}),this.renderAndResetBound=this.renderAndReset.bind(this),this.requestRenderAllBound=this.requestRenderAll.bind(this),this._initStatic(e,t)},backgroundColor:"",backgroundImage:null,overlayColor:"",overlayImage:null,includeDefaultValues:!0,stateful:!1,renderOnAddRemove:!0,controlsAboveOverlay:!1,allowTouchScrolling:!1,imageSmoothingEnabled:!0,viewportTransform:n.iMatrix.concat(),backgroundVpt:!0,overlayVpt:!0,enableRetinaScaling:!0,vptCoords:{},skipOffscreen:!0,clipPath:void 0,_initStatic:function(e,t){var i=this.requestRenderAllBound;this._objects=[],this._createLowerCanvas(e),this._initOptions(t),this.interactive||this._initRetinaScaling(),t.overlayImage&&this.setOverlayImage(t.overlayImage,i),t.backgroundImage&&this.setBackgroundImage(t.backgroundImage,i),t.backgroundColor&&this.setBackgroundColor(t.backgroundColor,i),t.overlayColor&&this.setOverlayColor(t.overlayColor,i),this.calcOffset()},_isRetinaScaling:function(){return n.devicePixelRatio>1&&this.enableRetinaScaling},getRetinaScaling:function(){return this._isRetinaScaling()?Math.max(1,n.devicePixelRatio):1},_initRetinaScaling:function(){if(this._isRetinaScaling()){var e=n.devicePixelRatio;this.__initRetinaScaling(e,this.lowerCanvasEl,this.contextContainer),this.upperCanvasEl&&this.__initRetinaScaling(e,this.upperCanvasEl,this.contextTop)}},__initRetinaScaling:function(e,t,i){t.setAttribute("width",this.width*e),t.setAttribute("height",this.height*e),i.scale(e,e)},calcOffset:function(){return this._offset=t(this.lowerCanvasEl),this},setOverlayImage:function(e,t,i){return this.__setBgOverlayImage("overlayImage",e,t,i)},setBackgroundImage:function(e,t,i){return this.__setBgOverlayImage("backgroundImage",e,t,i)},setOverlayColor:function(e,t){return this.__setBgOverlayColor("overlayColor",e,t)},setBackgroundColor:function(e,t){return this.__setBgOverlayColor("backgroundColor",e,t)},__setBgOverlayImage:function(e,t,i,s){return"string"===typeof t?n.util.loadImage(t,(function(t,r){if(t){var o=new n.Image(t,s);this[e]=o,o.canvas=this}i&&i(t,r)}),this,s&&s.crossOrigin):(s&&t.setOptions(s),this[e]=t,t&&(t.canvas=this),i&&i(t,!1)),this},__setBgOverlayColor:function(e,t,i){return this[e]=t,this._initGradient(t,e),this._initPattern(t,e,i),this},_createCanvasElement:function(){var e=l();if(!e)throw c;if(e.style||(e.style={}),"undefined"===typeof e.getContext)throw c;return e},_initOptions:function(e){var t=this.lowerCanvasEl;this._setOptions(e),this.width=this.width||parseInt(t.width,10)||0,this.height=this.height||parseInt(t.height,10)||0,this.lowerCanvasEl.style&&(t.width=this.width,t.height=this.height,t.style.width=this.width+"px",t.style.height=this.height+"px",this.viewportTransform=this.viewportTransform.slice())},_createLowerCanvas:function(e){e&&e.getContext?this.lowerCanvasEl=e:this.lowerCanvasEl=n.util.getById(e)||this._createCanvasElement(),n.util.addClass(this.lowerCanvasEl,"lower-canvas"),this._originalCanvasStyle=this.lowerCanvasEl.style,this.interactive&&this._applyCanvasStyle(this.lowerCanvasEl),this.contextContainer=this.lowerCanvasEl.getContext("2d")},getWidth:function(){return this.width},getHeight:function(){return this.height},setWidth:function(e,t){return this.setDimensions({width:e},t)},setHeight:function(e,t){return this.setDimensions({height:e},t)},setDimensions:function(e,t){var i;for(var s in t=t||{},e)i=e[s],t.cssOnly||(this._setBackstoreDimension(s,e[s]),i+="px",this.hasLostContext=!0),t.backstoreOnly||this._setCssDimension(s,i);return this._isCurrentlyDrawing&&this.freeDrawingBrush&&this.freeDrawingBrush._setBrushStyles(this.contextTop),this._initRetinaScaling(),this.calcOffset(),t.cssOnly||this.requestRenderAll(),this},_setBackstoreDimension:function(e,t){return this.lowerCanvasEl[e]=t,this.upperCanvasEl&&(this.upperCanvasEl[e]=t),this.cacheCanvasEl&&(this.cacheCanvasEl[e]=t),this[e]=t,this},_setCssDimension:function(e,t){return this.lowerCanvasEl.style[e]=t,this.upperCanvasEl&&(this.upperCanvasEl.style[e]=t),this.wrapperEl&&(this.wrapperEl.style[e]=t),this},getZoom:function(){return this.viewportTransform[0]},setViewportTransform:function(e){var t,i,s,n=this._activeObject,r=this.backgroundImage,o=this.overlayImage;for(this.viewportTransform=e,i=0,s=this._objects.length;i\n'),this._setSVGBgOverlayColor(i,"background"),this._setSVGBgOverlayImage(i,"backgroundImage",t),this._setSVGObjects(i,t),this.clipPath&&i.push("\n"),this._setSVGBgOverlayColor(i,"overlay"),this._setSVGBgOverlayImage(i,"overlayImage",t),i.push(""),i.join("")},_setSVGPreamble:function(e,t){t.suppressPreamble||e.push('\n','\n')},_setSVGHeader:function(e,t){var i,r=t.width||this.width,o=t.height||this.height,a='viewBox="0 0 '+this.width+" "+this.height+'" ',l=n.Object.NUM_FRACTION_DIGITS;t.viewBox?a='viewBox="'+t.viewBox.x+" "+t.viewBox.y+" "+t.viewBox.width+" "+t.viewBox.height+'" ':this.svgViewportTransformation&&(i=this.viewportTransform,a='viewBox="'+s(-i[4]/i[0],l)+" "+s(-i[5]/i[3],l)+" "+s(this.width/i[0],l)+" "+s(this.height/i[3],l)+'" '),e.push("\n',"Created with Fabric.js ",n.version,"\n","\n",this.createSVGFontFacesMarkup(),this.createSVGRefElementsMarkup(),this.createSVGClipPathMarkup(t),"\n")},createSVGClipPathMarkup:function(e){var t=this.clipPath;return t?(t.clipPathId="CLIPPATH_"+n.Object.__uid++,'\n'+this.clipPath.toClipPathSVG(e.reviver)+"\n"):""},createSVGRefElementsMarkup:function(){var e=this;return["background","overlay"].map((function(t){var i=e[t+"Color"];if(i&&i.toLive){var s=e[t+"Vpt"],r=e.viewportTransform,o={width:e.width/(s?r[0]:1),height:e.height/(s?r[3]:1)};return i.toSVG(o,{additionalTransform:s?n.util.matrixToSVG(r):""})}})).join("")},createSVGFontFacesMarkup:function(){var e,t,i,s,r,o,a,l,c="",h={},d=n.fontPaths,u=[];for(this._objects.forEach((function e(t){u.push(t),t._objects&&t._objects.forEach(e)})),a=0,l=u.length;a',"\n",c,"","\n"].join("")),c},_setSVGObjects:function(e,t){var i,s,n,r=this._objects;for(s=0,n=r.length;s\n")}else e.push('\n")},sendToBack:function(e){if(!e)return this;var t,s,n,r=this._activeObject;if(e===r&&"activeSelection"===e.type)for(t=(n=r._objects).length;t--;)s=n[t],i(this._objects,s),this._objects.unshift(s);else i(this._objects,e),this._objects.unshift(e);return this.renderOnAddRemove&&this.requestRenderAll(),this},bringToFront:function(e){if(!e)return this;var t,s,n,r=this._activeObject;if(e===r&&"activeSelection"===e.type)for(n=r._objects,t=0;t0+c&&(o=r-1,i(this._objects,n),this._objects.splice(o,0,n)),c++;else 0!==(r=this._objects.indexOf(e))&&(o=this._findNewLowerIndex(e,r,t),i(this._objects,e),this._objects.splice(o,0,e));return this.renderOnAddRemove&&this.requestRenderAll(),this},_findNewLowerIndex:function(e,t,i){var s,n;if(i)for(s=t,n=t-1;n>=0;--n){if(e.intersectsWithObject(this._objects[n])||e.isContainedWithinObject(this._objects[n])||this._objects[n].isContainedWithinObject(e)){s=n;break}}else s=t-1;return s},bringForward:function(e,t){if(!e)return this;var s,n,r,o,a,l=this._activeObject,c=0;if(e===l&&"activeSelection"===e.type)for(s=(a=l._objects).length;s--;)n=a[s],(r=this._objects.indexOf(n))"}}),e(n.StaticCanvas.prototype,n.Observable),e(n.StaticCanvas.prototype,n.Collection),e(n.StaticCanvas.prototype,n.DataURLExporter),e(n.StaticCanvas,{EMPTY_JSON:'{"objects": [], "background": "white"}',supports:function(e){var t=l();if(!t||!t.getContext)return null;var i=t.getContext("2d");return i&&"setLineDash"===e?"undefined"!==typeof i.setLineDash:null}}),n.StaticCanvas.prototype.toJSON=n.StaticCanvas.prototype.toObject,n.isLikelyNode&&(n.StaticCanvas.prototype.createPNGStream=function(){var e=a(this.lowerCanvasEl);return e&&e.createPNGStream()},n.StaticCanvas.prototype.createJPEGStream=function(e){var t=a(this.lowerCanvasEl);return t&&t.createJPEGStream(e)})}}(),n.BaseBrush=n.util.createClass({color:"rgb(0, 0, 0)",width:1,shadow:null,strokeLineCap:"round",strokeLineJoin:"round",strokeMiterLimit:10,strokeDashArray:null,limitedToCanvasSize:!1,_setBrushStyles:function(e){e.strokeStyle=this.color,e.lineWidth=this.width,e.lineCap=this.strokeLineCap,e.miterLimit=this.strokeMiterLimit,e.lineJoin=this.strokeLineJoin,e.setLineDash(this.strokeDashArray||[])},_saveAndTransform:function(e){var t=this.canvas.viewportTransform;e.save(),e.transform(t[0],t[1],t[2],t[3],t[4],t[5])},_setShadow:function(){if(this.shadow){var e=this.canvas,t=this.shadow,i=e.contextTop,s=e.getZoom();e&&e._isRetinaScaling()&&(s*=n.devicePixelRatio),i.shadowColor=t.color,i.shadowBlur=t.blur*s,i.shadowOffsetX=t.offsetX*s,i.shadowOffsetY=t.offsetY*s}},needsFullRender:function(){return new n.Color(this.color).getAlpha()<1||!!this.shadow},_resetShadow:function(){var e=this.canvas.contextTop;e.shadowColor="",e.shadowBlur=e.shadowOffsetX=e.shadowOffsetY=0},_isOutSideCanvas:function(e){return e.x<0||e.x>this.canvas.getWidth()||e.y<0||e.y>this.canvas.getHeight()}}),n.PencilBrush=n.util.createClass(n.BaseBrush,{decimate:.4,drawStraightLine:!1,straightLineKey:"shiftKey",initialize:function(e){this.canvas=e,this._points=[]},needsFullRender:function(){return this.callSuper("needsFullRender")||this._hasStraightLine},_drawSegment:function(e,t,i){var s=t.midPointFrom(i);return e.quadraticCurveTo(t.x,t.y,s.x,s.y),s},onMouseDown:function(e,t){this.canvas._isMainEvent(t.e)&&(this.drawStraightLine=t.e[this.straightLineKey],this._prepareForDrawing(e),this._captureDrawingPath(e),this._render())},onMouseMove:function(e,t){if(this.canvas._isMainEvent(t.e)&&(this.drawStraightLine=t.e[this.straightLineKey],(!0!==this.limitedToCanvasSize||!this._isOutSideCanvas(e))&&this._captureDrawingPath(e)&&this._points.length>1))if(this.needsFullRender())this.canvas.clearContext(this.canvas.contextTop),this._render();else{var i=this._points,s=i.length,n=this.canvas.contextTop;this._saveAndTransform(n),this.oldEnd&&(n.beginPath(),n.moveTo(this.oldEnd.x,this.oldEnd.y)),this.oldEnd=this._drawSegment(n,i[s-2],i[s-1],!0),n.stroke(),n.restore()}},onMouseUp:function(e){return!this.canvas._isMainEvent(e.e)||(this.drawStraightLine=!1,this.oldEnd=void 0,this._finalizeAndAddPath(),!1)},_prepareForDrawing:function(e){var t=new n.Point(e.x,e.y);this._reset(),this._addPoint(t),this.canvas.contextTop.moveTo(t.x,t.y)},_addPoint:function(e){return!(this._points.length>1&&e.eq(this._points[this._points.length-1]))&&(this.drawStraightLine&&this._points.length>1&&(this._hasStraightLine=!0,this._points.pop()),this._points.push(e),!0)},_reset:function(){this._points=[],this._setBrushStyles(this.canvas.contextTop),this._setShadow(),this._hasStraightLine=!1},_captureDrawingPath:function(e){var t=new n.Point(e.x,e.y);return this._addPoint(t)},_render:function(e){var t,i,s=this._points[0],r=this._points[1];if(e=e||this.canvas.contextTop,this._saveAndTransform(e),e.beginPath(),2===this._points.length&&s.x===r.x&&s.y===r.y){var o=this.width/1e3;s=new n.Point(s.x,s.y),r=new n.Point(r.x,r.y),s.x-=o,r.x+=o}for(e.moveTo(s.x,s.y),t=1,i=this._points.length;t=n&&(o=e[i],a.push(o));return a.push(e[r]),a},_finalizeAndAddPath:function(){this.canvas.contextTop.closePath(),this.decimate&&(this._points=this.decimatePoints(this._points,this.decimate));var e=this.convertPointsToSVGPath(this._points);if(this._isEmptySVGPath(e))this.canvas.requestRenderAll();else{var t=this.createPath(e);this.canvas.clearContext(this.canvas.contextTop),this.canvas.fire("before:path:created",{path:t}),this.canvas.add(t),this.canvas.requestRenderAll(),t.setCoords(),this._resetShadow(),this.canvas.fire("path:created",{path:t})}}}),n.CircleBrush=n.util.createClass(n.BaseBrush,{width:10,initialize:function(e){this.canvas=e,this.points=[]},drawDot:function(e){var t=this.addPoint(e),i=this.canvas.contextTop;this._saveAndTransform(i),this.dot(i,t),i.restore()},dot:function(e,t){e.fillStyle=t.fill,e.beginPath(),e.arc(t.x,t.y,t.radius,0,2*Math.PI,!1),e.closePath(),e.fill()},onMouseDown:function(e){this.points.length=0,this.canvas.clearContext(this.canvas.contextTop),this._setShadow(),this.drawDot(e)},_render:function(){var e,t,i=this.canvas.contextTop,s=this.points;for(this._saveAndTransform(i),e=0,t=s.length;e0&&!this.preserveObjectStacking){t=[],i=[];for(var n=0,r=this._objects.length;n1&&(this._activeObject._objects=i),t.push.apply(t,i)}else t=this._objects;return t},renderAll:function(){!this.contextTopDirty||this._groupSelector||this.isDrawingMode||(this.clearContext(this.contextTop),this.contextTopDirty=!1),this.hasLostContext&&(this.renderTopLayer(this.contextTop),this.hasLostContext=!1);var e=this.contextContainer;return this.renderCanvas(e,this._chooseObjectsToRender()),this},renderTopLayer:function(e){e.save(),this.isDrawingMode&&this._isCurrentlyDrawing&&(this.freeDrawingBrush&&this.freeDrawingBrush._render(),this.contextTopDirty=!0),this.selection&&this._groupSelector&&(this._drawSelection(e),this.contextTopDirty=!0),e.restore()},renderTop:function(){var e=this.contextTop;return this.clearContext(e),this.renderTopLayer(e),this.fire("after:render"),this},_normalizePointer:function(e,t){var i=e.calcTransformMatrix(),s=n.util.invertTransform(i),r=this.restorePointerVpt(t);return n.util.transformPoint(r,s)},isTargetTransparent:function(e,t,i){if(e.shouldCache()&&e._cacheCanvas&&e!==this._activeObject){var s=this._normalizePointer(e,{x:t,y:i}),r=Math.max(e.cacheTranslationX+s.x*e.zoomX,0),o=Math.max(e.cacheTranslationY+s.y*e.zoomY,0);return n.util.isTransparent(e._cacheContext,Math.round(r),Math.round(o),this.targetFindTolerance)}var a=this.contextCache,l=e.selectionBackgroundColor,c=this.viewportTransform;return e.selectionBackgroundColor="",this.clearContext(a),a.save(),a.transform(c[0],c[1],c[2],c[3],c[4],c[5]),e.render(a),a.restore(),e.selectionBackgroundColor=l,n.util.isTransparent(a,t,i,this.targetFindTolerance)},_isSelectionKeyPressed:function(e){return Array.isArray(this.selectionKey)?!!this.selectionKey.find((function(t){return!0===e[t]})):e[this.selectionKey]},_shouldClearSelection:function(e,t){var i=this.getActiveObjects(),s=this._activeObject;return!t||t&&s&&i.length>1&&-1===i.indexOf(t)&&s!==t&&!this._isSelectionKeyPressed(e)||t&&!t.evented||t&&!t.selectable&&s&&s!==t},_shouldCenterTransform:function(e,t,i){var s;if(e)return"scale"===t||"scaleX"===t||"scaleY"===t||"resizing"===t?s=this.centeredScaling||e.centeredScaling:"rotate"===t&&(s=this.centeredRotation||e.centeredRotation),s?!i:i},_getOriginFromCorner:function(e,t){var i={x:e.originX,y:e.originY};return"ml"===t||"tl"===t||"bl"===t?i.x="right":"mr"!==t&&"tr"!==t&&"br"!==t||(i.x="left"),"tl"===t||"mt"===t||"tr"===t?i.y="bottom":"bl"!==t&&"mb"!==t&&"br"!==t||(i.y="top"),i},_getActionFromCorner:function(e,t,i,s){if(!t||!e)return"drag";var n=s.controls[t];return n.getActionName(i,n,s)},_setupCurrentTransform:function(e,i,s){if(i){var r=this.getPointer(e),o=i.__corner,a=i.controls[o],l=s&&o?a.getActionHandler(e,i,a):n.controlsUtils.dragHandler,c=this._getActionFromCorner(s,o,e,i),h=this._getOriginFromCorner(i,o),d=e[this.centeredKey],u={target:i,action:c,actionHandler:l,corner:o,scaleX:i.scaleX,scaleY:i.scaleY,skewX:i.skewX,skewY:i.skewY,offsetX:r.x-i.left,offsetY:r.y-i.top,originX:h.x,originY:h.y,ex:r.x,ey:r.y,lastX:r.x,lastY:r.y,theta:t(i.angle),width:i.width*i.scaleX,shiftKey:e.shiftKey,altKey:d,original:n.util.saveObjectTransform(i)};this._shouldCenterTransform(i,c,d)&&(u.originX="center",u.originY="center"),u.original.originX=h.x,u.original.originY=h.y,this._currentTransform=u,this._beforeTransform(e)}},setCursor:function(e){this.upperCanvasEl.style.cursor=e},_drawSelection:function(e){var t=this._groupSelector,i=new n.Point(t.ex,t.ey),s=n.util.transformPoint(i,this.viewportTransform),r=new n.Point(t.ex+t.left,t.ey+t.top),o=n.util.transformPoint(r,this.viewportTransform),a=Math.min(s.x,o.x),l=Math.min(s.y,o.y),c=Math.max(s.x,o.x),h=Math.max(s.y,o.y),d=this.selectionLineWidth/2;this.selectionColor&&(e.fillStyle=this.selectionColor,e.fillRect(a,l,c-a,h-l)),this.selectionLineWidth&&this.selectionBorderColor&&(e.lineWidth=this.selectionLineWidth,e.strokeStyle=this.selectionBorderColor,a+=d,l+=d,c-=d,h-=d,n.Object.prototype._setLineDash.call(this,e,this.selectionDashArray),e.strokeRect(a,l,c-a,h-l))},findTarget:function(e,t){if(!this.skipTargetFind){var s,n,r=this.getPointer(e,!0),o=this._activeObject,a=this.getActiveObjects(),l=i(e),c=a.length>1&&!t||1===a.length;if(this.targets=[],c&&o._findTargetCorner(r,l))return o;if(a.length>1&&!t&&o===this._searchPossibleTargets([o],r))return o;if(1===a.length&&o===this._searchPossibleTargets([o],r)){if(!this.preserveObjectStacking)return o;s=o,n=this.targets,this.targets=[]}var h=this._searchPossibleTargets(this._objects,r);return e[this.altSelectionKey]&&h&&s&&h!==s&&(h=s,this.targets=n),h}},_checkTarget:function(e,t,i){if(t&&t.visible&&t.evented&&t.containsPoint(e)){if(!this.perPixelTargetFind&&!t.perPixelTargetFind||t.isEditing)return!0;if(!this.isTargetTransparent(t,i.x,i.y))return!0}},_searchPossibleTargets:function(e,t){for(var i,s,r=e.length;r--;){var o=e[r],a=o.group?this._normalizePointer(o.group,t):t;if(this._checkTarget(a,o,t)){(i=e[r]).subTargetCheck&&i instanceof n.Group&&(s=this._searchPossibleTargets(i._objects,t))&&this.targets.push(s);break}}return i},restorePointerVpt:function(e){return n.util.transformPoint(e,n.util.invertTransform(this.viewportTransform))},getPointer:function(t,i){if(this._absolutePointer&&!i)return this._absolutePointer;if(this._pointer&&i)return this._pointer;var s,n=e(t),r=this.upperCanvasEl,o=r.getBoundingClientRect(),a=o.width||0,l=o.height||0;a&&l||("top"in o&&"bottom"in o&&(l=Math.abs(o.top-o.bottom)),"right"in o&&"left"in o&&(a=Math.abs(o.right-o.left))),this.calcOffset(),n.x=n.x-this._offset.left,n.y=n.y-this._offset.top,i||(n=this.restorePointerVpt(n));var c=this.getRetinaScaling();return 1!==c&&(n.x/=c,n.y/=c),s=0===a||0===l?{width:1,height:1}:{width:r.width/a,height:r.height/l},{x:n.x*s.width,y:n.y*s.height}},_createUpperCanvas:function(){var e=this.lowerCanvasEl.className.replace(/\s*lower-canvas\s*/,""),t=this.lowerCanvasEl,i=this.upperCanvasEl;i?i.className="":(i=this._createCanvasElement(),this.upperCanvasEl=i),n.util.addClass(i,"upper-canvas "+e),this.wrapperEl.appendChild(i),this._copyCanvasStyle(t,i),this._applyCanvasStyle(i),this.contextTop=i.getContext("2d")},getTopContext:function(){return this.contextTop},_createCacheCanvas:function(){this.cacheCanvasEl=this._createCanvasElement(),this.cacheCanvasEl.setAttribute("width",this.width),this.cacheCanvasEl.setAttribute("height",this.height),this.contextCache=this.cacheCanvasEl.getContext("2d")},_initWrapperElement:function(){this.wrapperEl=n.util.wrapElement(this.lowerCanvasEl,"div",{class:this.containerClass}),n.util.setStyle(this.wrapperEl,{width:this.width+"px",height:this.height+"px",position:"relative"}),n.util.makeElementUnselectable(this.wrapperEl)},_applyCanvasStyle:function(e){var t=this.width||e.width,i=this.height||e.height;n.util.setStyle(e,{position:"absolute",width:t+"px",height:i+"px",left:0,top:0,"touch-action":this.allowTouchScrolling?"manipulation":"none","-ms-touch-action":this.allowTouchScrolling?"manipulation":"none"}),e.width=t,e.height=i,n.util.makeElementUnselectable(e)},_copyCanvasStyle:function(e,t){t.style.cssText=e.style.cssText},getSelectionContext:function(){return this.contextTop},getSelectionElement:function(){return this.upperCanvasEl},getActiveObject:function(){return this._activeObject},getActiveObjects:function(){var e=this._activeObject;return e?"activeSelection"===e.type&&e._objects?e._objects.slice(0):[e]:[]},_onObjectRemoved:function(e){e===this._activeObject&&(this.fire("before:selection:cleared",{target:e}),this._discardActiveObject(),this.fire("selection:cleared",{target:e}),e.fire("deselected")),e===this._hoveredTarget&&(this._hoveredTarget=null,this._hoveredTargets=[]),this.callSuper("_onObjectRemoved",e)},_fireSelectionEvents:function(e,t){var i=!1,s=this.getActiveObjects(),n=[],r=[];e.forEach((function(e){-1===s.indexOf(e)&&(i=!0,e.fire("deselected",{e:t,target:e}),r.push(e))})),s.forEach((function(s){-1===e.indexOf(s)&&(i=!0,s.fire("selected",{e:t,target:s}),n.push(s))})),e.length>0&&s.length>0?i&&this.fire("selection:updated",{e:t,selected:n,deselected:r}):s.length>0?this.fire("selection:created",{e:t,selected:n}):e.length>0&&this.fire("selection:cleared",{e:t,deselected:r})},setActiveObject:function(e,t){var i=this.getActiveObjects();return this._setActiveObject(e,t),this._fireSelectionEvents(i,t),this},_setActiveObject:function(e,t){return this._activeObject!==e&&(!!this._discardActiveObject(t,e)&&(!e.onSelect({e:t})&&(this._activeObject=e,!0)))},_discardActiveObject:function(e,t){var i=this._activeObject;if(i){if(i.onDeselect({e:e,object:t}))return!1;this._activeObject=null}return!0},discardActiveObject:function(e){var t=this.getActiveObjects(),i=this.getActiveObject();return t.length&&this.fire("before:selection:cleared",{target:i,e:e}),this._discardActiveObject(e),this._fireSelectionEvents(t,e),this},dispose:function(){var e=this.wrapperEl;return this.removeListeners(),e.removeChild(this.upperCanvasEl),e.removeChild(this.lowerCanvasEl),this.contextCache=null,this.contextTop=null,["upperCanvasEl","cacheCanvasEl"].forEach(function(e){n.util.cleanUpJsdomNode(this[e]),this[e]=void 0}.bind(this)),e.parentNode&&e.parentNode.replaceChild(this.lowerCanvasEl,this.wrapperEl),delete this.wrapperEl,n.StaticCanvas.prototype.dispose.call(this),this},clear:function(){return this.discardActiveObject(),this.clearContext(this.contextTop),this.callSuper("clear")},drawControls:function(e){var t=this._activeObject;t&&t._renderControls(e)},_toObject:function(e,t,i){var s=this._realizeGroupTransformOnObject(e),n=this.callSuper("_toObject",e,t,i);return this._unwindGroupTransformOnObject(e,s),n},_realizeGroupTransformOnObject:function(e){if(e.group&&"activeSelection"===e.group.type&&this._activeObject===e.group){var t={};return["angle","flipX","flipY","left","scaleX","scaleY","skewX","skewY","top"].forEach((function(i){t[i]=e[i]})),n.util.addTransformToObject(e,this._activeObject.calcOwnMatrix()),t}return null},_unwindGroupTransformOnObject:function(e,t){t&&e.set(t)},_setSVGObject:function(e,t,i){var s=this._realizeGroupTransformOnObject(t);this.callSuper("_setSVGObject",e,t,i),this._unwindGroupTransformOnObject(t,s)},setViewportTransform:function(e){this.renderOnAddRemove&&this._activeObject&&this._activeObject.isEditing&&this._activeObject.clearContextTop(),n.StaticCanvas.prototype.setViewportTransform.call(this,e)}}),n.StaticCanvas)"prototype"!==s&&(n.Canvas[s]=n.StaticCanvas[s])}(),function(){var e=n.util.addListener,t=n.util.removeListener,i={passive:!1};function s(e,t){return e.button&&e.button===t-1}n.util.object.extend(n.Canvas.prototype,{mainTouchId:null,_initEventListeners:function(){this.removeListeners(),this._bindEvents(),this.addOrRemove(e,"add")},_getEventPrefix:function(){return this.enablePointerEvents?"pointer":"mouse"},addOrRemove:function(e,t){var s=this.upperCanvasEl,r=this._getEventPrefix();e(n.window,"resize",this._onResize),e(s,r+"down",this._onMouseDown),e(s,r+"move",this._onMouseMove,i),e(s,r+"out",this._onMouseOut),e(s,r+"enter",this._onMouseEnter),e(s,"wheel",this._onMouseWheel),e(s,"contextmenu",this._onContextMenu),e(s,"dblclick",this._onDoubleClick),e(s,"dragover",this._onDragOver),e(s,"dragenter",this._onDragEnter),e(s,"dragleave",this._onDragLeave),e(s,"drop",this._onDrop),this.enablePointerEvents||e(s,"touchstart",this._onTouchStart,i),"undefined"!==typeof eventjs&&t in eventjs&&(eventjs[t](s,"gesture",this._onGesture),eventjs[t](s,"drag",this._onDrag),eventjs[t](s,"orientation",this._onOrientationChange),eventjs[t](s,"shake",this._onShake),eventjs[t](s,"longpress",this._onLongPress))},removeListeners:function(){this.addOrRemove(t,"remove");var e=this._getEventPrefix();t(n.document,e+"up",this._onMouseUp),t(n.document,"touchend",this._onTouchEnd,i),t(n.document,e+"move",this._onMouseMove,i),t(n.document,"touchmove",this._onMouseMove,i)},_bindEvents:function(){this.eventsBound||(this._onMouseDown=this._onMouseDown.bind(this),this._onTouchStart=this._onTouchStart.bind(this),this._onMouseMove=this._onMouseMove.bind(this),this._onMouseUp=this._onMouseUp.bind(this),this._onTouchEnd=this._onTouchEnd.bind(this),this._onResize=this._onResize.bind(this),this._onGesture=this._onGesture.bind(this),this._onDrag=this._onDrag.bind(this),this._onShake=this._onShake.bind(this),this._onLongPress=this._onLongPress.bind(this),this._onOrientationChange=this._onOrientationChange.bind(this),this._onMouseWheel=this._onMouseWheel.bind(this),this._onMouseOut=this._onMouseOut.bind(this),this._onMouseEnter=this._onMouseEnter.bind(this),this._onContextMenu=this._onContextMenu.bind(this),this._onDoubleClick=this._onDoubleClick.bind(this),this._onDragOver=this._onDragOver.bind(this),this._onDragEnter=this._simpleEventHandler.bind(this,"dragenter"),this._onDragLeave=this._simpleEventHandler.bind(this,"dragleave"),this._onDrop=this._onDrop.bind(this),this.eventsBound=!0)},_onGesture:function(e,t){this.__onTransformGesture&&this.__onTransformGesture(e,t)},_onDrag:function(e,t){this.__onDrag&&this.__onDrag(e,t)},_onMouseWheel:function(e){this.__onMouseWheel(e)},_onMouseOut:function(e){var t=this._hoveredTarget;this.fire("mouse:out",{target:t,e:e}),this._hoveredTarget=null,t&&t.fire("mouseout",{e:e});var i=this;this._hoveredTargets.forEach((function(t){i.fire("mouse:out",{target:t,e:e}),t&&t.fire("mouseout",{e:e})})),this._hoveredTargets=[]},_onMouseEnter:function(e){this._currentTransform||this.findTarget(e)||(this.fire("mouse:over",{target:null,e:e}),this._hoveredTarget=null,this._hoveredTargets=[])},_onOrientationChange:function(e,t){this.__onOrientationChange&&this.__onOrientationChange(e,t)},_onShake:function(e,t){this.__onShake&&this.__onShake(e,t)},_onLongPress:function(e,t){this.__onLongPress&&this.__onLongPress(e,t)},_onDragOver:function(e){e.preventDefault();var t=this._simpleEventHandler("dragover",e);this._fireEnterLeaveEvents(t,e)},_onDrop:function(e){return this._simpleEventHandler("drop:before",e),this._simpleEventHandler("drop",e)},_onContextMenu:function(e){return this.stopContextMenu&&(e.stopPropagation(),e.preventDefault()),!1},_onDoubleClick:function(e){this._cacheTransformEventData(e),this._handleEvent(e,"dblclick"),this._resetTransformEventData(e)},getPointerId:function(e){var t=e.changedTouches;return t?t[0]&&t[0].identifier:this.enablePointerEvents?e.pointerId:-1},_isMainEvent:function(e){return!0===e.isPrimary||!1!==e.isPrimary&&("touchend"===e.type&&0===e.touches.length||(!e.changedTouches||e.changedTouches[0].identifier===this.mainTouchId))},_onTouchStart:function(s){s.preventDefault(),null===this.mainTouchId&&(this.mainTouchId=this.getPointerId(s)),this.__onMouseDown(s),this._resetTransformEventData();var r=this.upperCanvasEl,o=this._getEventPrefix();e(n.document,"touchend",this._onTouchEnd,i),e(n.document,"touchmove",this._onMouseMove,i),t(r,o+"down",this._onMouseDown)},_onMouseDown:function(s){this.__onMouseDown(s),this._resetTransformEventData();var r=this.upperCanvasEl,o=this._getEventPrefix();t(r,o+"move",this._onMouseMove,i),e(n.document,o+"up",this._onMouseUp),e(n.document,o+"move",this._onMouseMove,i)},_onTouchEnd:function(s){if(!(s.touches.length>0)){this.__onMouseUp(s),this._resetTransformEventData(),this.mainTouchId=null;var r=this._getEventPrefix();t(n.document,"touchend",this._onTouchEnd,i),t(n.document,"touchmove",this._onMouseMove,i);var o=this;this._willAddMouseDown&&clearTimeout(this._willAddMouseDown),this._willAddMouseDown=setTimeout((function(){e(o.upperCanvasEl,r+"down",o._onMouseDown),o._willAddMouseDown=0}),400)}},_onMouseUp:function(s){this.__onMouseUp(s),this._resetTransformEventData();var r=this.upperCanvasEl,o=this._getEventPrefix();this._isMainEvent(s)&&(t(n.document,o+"up",this._onMouseUp),t(n.document,o+"move",this._onMouseMove,i),e(r,o+"move",this._onMouseMove,i))},_onMouseMove:function(e){!this.allowTouchScrolling&&e.preventDefault&&e.preventDefault(),this.__onMouseMove(e)},_onResize:function(){this.calcOffset()},_shouldRender:function(e){var t=this._activeObject;return!!(!!t!==!!e||t&&e&&t!==e)||(t&&t.isEditing,!1)},__onMouseUp:function(e){var t,i=this._currentTransform,r=this._groupSelector,o=!1,a=!r||0===r.left&&0===r.top;if(this._cacheTransformEventData(e),t=this._target,this._handleEvent(e,"up:before"),s(e,3))this.fireRightClick&&this._handleEvent(e,"up",3,a);else{if(s(e,2))return this.fireMiddleClick&&this._handleEvent(e,"up",2,a),void this._resetTransformEventData();if(this.isDrawingMode&&this._isCurrentlyDrawing)this._onMouseUpInDrawingMode(e);else if(this._isMainEvent(e)){if(i&&(this._finalizeCurrentTransform(e),o=i.actionPerformed),!a){var l=t===this._activeObject;this._maybeGroupObjects(e),o||(o=this._shouldRender(t)||!l&&t===this._activeObject)}var c,h;if(t){if(c=t._findTargetCorner(this.getPointer(e,!0),n.util.isTouchEvent(e)),t.selectable&&t!==this._activeObject&&"up"===t.activeOn)this.setActiveObject(t,e),o=!0;else{var d=t.controls[c],u=d&&d.getMouseUpHandler(e,t,d);u&&u(e,i,(h=this.getPointer(e)).x,h.y)}t.isMoving=!1}if(i&&(i.target!==t||i.corner!==c)){var g=i.target&&i.target.controls[i.corner],p=g&&g.getMouseUpHandler(e,t,d);h=h||this.getPointer(e),p&&p(e,i,h.x,h.y)}this._setCursorFromEvent(e,t),this._handleEvent(e,"up",1,a),this._groupSelector=null,this._currentTransform=null,t&&(t.__corner=0),o?this.requestRenderAll():a||this.renderTop()}}},_simpleEventHandler:function(e,t){var i=this.findTarget(t),s=this.targets,n={e:t,target:i,subTargets:s};if(this.fire(e,n),i&&i.fire(e,n),!s)return i;for(var r=0;r1&&(t=new n.ActiveSelection(i.reverse(),{canvas:this}),this.setActiveObject(t,e))},_collectObjects:function(i){for(var s,r=[],o=this._groupSelector.ex,a=this._groupSelector.ey,l=o+this._groupSelector.left,c=a+this._groupSelector.top,h=new n.Point(e(o,l),e(a,c)),d=new n.Point(t(o,l),t(a,c)),u=!this.selectionFullyContained,g=o===l&&a===c,p=this._objects.length;p--&&!((s=this._objects[p])&&s.selectable&&s.visible&&(u&&s.intersectsWithRect(h,d,!0)||s.isContainedWithinRect(h,d,!0)||u&&s.containsPoint(h,null,!0)||u&&s.containsPoint(d,null,!0))&&(r.push(s),g)););return r.length>1&&(r=r.filter((function(e){return!e.onSelect({e:i})}))),r},_maybeGroupObjects:function(e){this.selection&&this._groupSelector&&this._groupSelectedObjects(e),this.setCursor(this.defaultCursor),this._groupSelector=null}})}(),n.util.object.extend(n.StaticCanvas.prototype,{toDataURL:function(e){e||(e={});var t=e.format||"png",i=e.quality||1,s=(e.multiplier||1)*(e.enableRetinaScaling?this.getRetinaScaling():1),r=this.toCanvasElement(s,e);return n.util.toDataURL(r,t,i)},toCanvasElement:function(e,t){e=e||1;var i=((t=t||{}).width||this.width)*e,s=(t.height||this.height)*e,r=this.getZoom(),o=this.width,a=this.height,l=r*e,c=this.viewportTransform,h=(c[4]-(t.left||0))*e,d=(c[5]-(t.top||0))*e,u=this.interactive,g=[l,0,0,l,h,d],p=this.enableRetinaScaling,m=n.util.createCanvasElement(),f=this.contextTop;return m.width=i,m.height=s,this.contextTop=null,this.enableRetinaScaling=!1,this.interactive=!1,this.viewportTransform=g,this.width=i,this.height=s,this.calcViewportBoundaries(),this.renderCanvas(m.getContext("2d"),this._objects),this.viewportTransform=c,this.width=o,this.height=a,this.calcViewportBoundaries(),this.interactive=u,this.enableRetinaScaling=p,this.contextTop=f,m}}),n.util.object.extend(n.StaticCanvas.prototype,{loadFromJSON:function(e,t,i){if(e){var s="string"===typeof e?JSON.parse(e):n.util.object.clone(e),r=this,o=s.clipPath,a=this.renderOnAddRemove;return this.renderOnAddRemove=!1,delete s.clipPath,this._enlivenObjects(s.objects,(function(e){r.clear(),r._setBgOverlay(s,(function(){o?r._enlivenObjects([o],(function(i){r.clipPath=i[0],r.__setupCanvas.call(r,s,e,a,t)})):r.__setupCanvas.call(r,s,e,a,t)}))}),i),this}},__setupCanvas:function(e,t,i,s){var n=this;t.forEach((function(e,t){n.insertAt(e,t)})),this.renderOnAddRemove=i,delete e.objects,delete e.backgroundImage,delete e.overlayImage,delete e.background,delete e.overlay,this._setOptions(e),this.renderAll(),s&&s()},_setBgOverlay:function(e,t){var i={backgroundColor:!1,overlayColor:!1,backgroundImage:!1,overlayImage:!1};if(e.backgroundImage||e.overlayImage||e.background||e.overlay){var s=function(){i.backgroundImage&&i.overlayImage&&i.backgroundColor&&i.overlayColor&&t&&t()};this.__setBgOverlay("backgroundImage",e.backgroundImage,i,s),this.__setBgOverlay("overlayImage",e.overlayImage,i,s),this.__setBgOverlay("backgroundColor",e.background,i,s),this.__setBgOverlay("overlayColor",e.overlay,i,s)}else t&&t()},__setBgOverlay:function(e,t,i,s){var r=this;if(!t)return i[e]=!0,void(s&&s());"backgroundImage"===e||"overlayImage"===e?n.util.enlivenObjects([t],(function(t){r[e]=t[0],i[e]=!0,s&&s()})):this["set"+n.util.string.capitalize(e,!0)](t,(function(){i[e]=!0,s&&s()}))},_enlivenObjects:function(e,t,i){e&&0!==e.length?n.util.enlivenObjects(e,(function(e){t&&t(e)}),null,i):t&&t([])},_toDataURL:function(e,t){this.clone((function(i){t(i.toDataURL(e))}))},_toDataURLWithMultiplier:function(e,t,i){this.clone((function(s){i(s.toDataURLWithMultiplier(e,t))}))},clone:function(e,t){var i=JSON.stringify(this.toJSON(t));this.cloneWithoutData((function(t){t.loadFromJSON(i,(function(){e&&e(t)}))}))},cloneWithoutData:function(e){var t=n.util.createCanvasElement();t.width=this.width,t.height=this.height;var i=new n.Canvas(t);this.backgroundImage?(i.setBackgroundImage(this.backgroundImage.src,(function(){i.renderAll(),e&&e(i)})),i.backgroundImageOpacity=this.backgroundImageOpacity,i.backgroundImageStretch=this.backgroundImageStretch):e&&e(i)}}),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.object.extend,s=t.util.object.clone,n=t.util.toFixed,r=t.util.string.capitalize,o=t.util.degreesToRadians,a=!t.isLikelyNode;t.Object||(t.Object=t.util.createClass(t.CommonMethods,{type:"object",originX:"left",originY:"top",top:0,left:0,width:0,height:0,scaleX:1,scaleY:1,flipX:!1,flipY:!1,opacity:1,angle:0,skewX:0,skewY:0,cornerSize:13,touchCornerSize:24,transparentCorners:!0,hoverCursor:null,moveCursor:null,padding:0,borderColor:"rgb(178,204,255)",borderDashArray:null,cornerColor:"rgb(178,204,255)",cornerStrokeColor:null,cornerStyle:"rect",cornerDashArray:null,centeredScaling:!1,centeredRotation:!0,fill:"rgb(0,0,0)",fillRule:"nonzero",globalCompositeOperation:"source-over",backgroundColor:"",selectionBackgroundColor:"",stroke:null,strokeWidth:1,strokeDashArray:null,strokeDashOffset:0,strokeLineCap:"butt",strokeLineJoin:"miter",strokeMiterLimit:4,shadow:null,borderOpacityWhenMoving:.4,borderScaleFactor:1,minScaleLimit:0,selectable:!0,evented:!0,visible:!0,hasControls:!0,hasBorders:!0,perPixelTargetFind:!1,includeDefaultValues:!0,lockMovementX:!1,lockMovementY:!1,lockRotation:!1,lockScalingX:!1,lockScalingY:!1,lockSkewingX:!1,lockSkewingY:!1,lockScalingFlip:!1,excludeFromExport:!1,objectCaching:a,statefullCache:!1,noScaleCache:!0,strokeUniform:!1,dirty:!0,__corner:0,paintFirst:"fill",activeOn:"down",stateProperties:"top left width height scaleX scaleY flipX flipY originX originY transformMatrix stroke strokeWidth strokeDashArray strokeLineCap strokeDashOffset strokeLineJoin strokeMiterLimit angle opacity fill globalCompositeOperation shadow visible backgroundColor skewX skewY fillRule paintFirst clipPath strokeUniform".split(" "),cacheProperties:"fill stroke strokeWidth strokeDashArray width height paintFirst strokeUniform strokeLineCap strokeDashOffset strokeLineJoin strokeMiterLimit backgroundColor clipPath".split(" "),colorProperties:"fill stroke backgroundColor".split(" "),clipPath:void 0,inverted:!1,absolutePositioned:!1,initialize:function(e){e&&this.setOptions(e)},_createCacheCanvas:function(){this._cacheProperties={},this._cacheCanvas=t.util.createCanvasElement(),this._cacheContext=this._cacheCanvas.getContext("2d"),this._updateCacheCanvas(),this.dirty=!0},_limitCacheSize:function(e){var i=t.perfLimitSizeTotal,s=e.width,n=e.height,r=t.maxCacheSideLimit,o=t.minCacheSideLimit;if(s<=r&&n<=r&&s*n<=i)return sh&&(e.zoomX/=s/h,e.width=h,e.capped=!0),n>d&&(e.zoomY/=n/d,e.height=d,e.capped=!0),e},_getCacheCanvasDimensions:function(){var e=this.getTotalObjectScaling(),t=this._getTransformedDimensions(0,0),i=t.x*e.scaleX/this.scaleX,s=t.y*e.scaleY/this.scaleY;return{width:Math.ceil(i+2),height:Math.ceil(s+2),zoomX:e.scaleX,zoomY:e.scaleY,x:i,y:s}},_updateCacheCanvas:function(){var e=this.canvas;if(this.noScaleCache&&e&&e._currentTransform){var t=e._currentTransform.target,i=e._currentTransform.action;if(this===t&&i.slice&&"scale"===i.slice(0,5))return!1}var s,n,r=this._cacheCanvas,o=this._limitCacheSize(this._getCacheCanvasDimensions()),a=o.width,l=o.height,c=o.zoomX,h=o.zoomY,d=a!==this.cacheWidth||l!==this.cacheHeight,u=this.zoomX!==c||this.zoomY!==h;return!(!d&&!u)&&(d?(r.width=a,r.height=l):(this._cacheContext.setTransform(1,0,0,1,0,0),this._cacheContext.clearRect(0,0,r.width,r.height)),s=o.x/2,n=o.y/2,this.cacheTranslationX=Math.round(r.width/2-s)+s,this.cacheTranslationY=Math.round(r.height/2-n)+n,this.cacheWidth=a,this.cacheHeight=l,this._cacheContext.translate(this.cacheTranslationX,this.cacheTranslationY),this._cacheContext.scale(c,h),this.zoomX=c,this.zoomY=h,!0)},setOptions:function(e){this._setOptions(e),this._initGradient(e.fill,"fill"),this._initGradient(e.stroke,"stroke"),this._initPattern(e.fill,"fill"),this._initPattern(e.stroke,"stroke")},transform:function(e){var t=this.group&&!this.group._transformDone||this.group&&this.canvas&&e===this.canvas.contextTop,i=this.calcTransformMatrix(!t);e.transform(i[0],i[1],i[2],i[3],i[4],i[5])},toObject:function(e){var i=t.Object.NUM_FRACTION_DIGITS,s={type:this.type,version:t.version,originX:this.originX,originY:this.originY,left:n(this.left,i),top:n(this.top,i),width:n(this.width,i),height:n(this.height,i),fill:this.fill&&this.fill.toObject?this.fill.toObject():this.fill,stroke:this.stroke&&this.stroke.toObject?this.stroke.toObject():this.stroke,strokeWidth:n(this.strokeWidth,i),strokeDashArray:this.strokeDashArray?this.strokeDashArray.concat():this.strokeDashArray,strokeLineCap:this.strokeLineCap,strokeDashOffset:this.strokeDashOffset,strokeLineJoin:this.strokeLineJoin,strokeUniform:this.strokeUniform,strokeMiterLimit:n(this.strokeMiterLimit,i),scaleX:n(this.scaleX,i),scaleY:n(this.scaleY,i),angle:n(this.angle,i),flipX:this.flipX,flipY:this.flipY,opacity:n(this.opacity,i),shadow:this.shadow&&this.shadow.toObject?this.shadow.toObject():this.shadow,visible:this.visible,backgroundColor:this.backgroundColor,fillRule:this.fillRule,paintFirst:this.paintFirst,globalCompositeOperation:this.globalCompositeOperation,skewX:n(this.skewX,i),skewY:n(this.skewY,i)};return this.clipPath&&!this.clipPath.excludeFromExport&&(s.clipPath=this.clipPath.toObject(e),s.clipPath.inverted=this.clipPath.inverted,s.clipPath.absolutePositioned=this.clipPath.absolutePositioned),t.util.populateWithProperties(this,s,e),this.includeDefaultValues||(s=this._removeDefaultValues(s)),s},toDatalessObject:function(e){return this.toObject(e)},_removeDefaultValues:function(e){var i=t.util.getKlass(e.type).prototype;return i.stateProperties.forEach((function(t){"left"!==t&&"top"!==t&&(e[t]===i[t]&&delete e[t],Array.isArray(e[t])&&Array.isArray(i[t])&&0===e[t].length&&0===i[t].length&&delete e[t])})),e},toString:function(){return"#"},getObjectScaling:function(){if(!this.group)return{scaleX:this.scaleX,scaleY:this.scaleY};var e=t.util.qrDecompose(this.calcTransformMatrix());return{scaleX:Math.abs(e.scaleX),scaleY:Math.abs(e.scaleY)}},getTotalObjectScaling:function(){var e=this.getObjectScaling(),t=e.scaleX,i=e.scaleY;if(this.canvas){var s=this.canvas.getZoom(),n=this.canvas.getRetinaScaling();t*=s*n,i*=s*n}return{scaleX:t,scaleY:i}},getObjectOpacity:function(){var e=this.opacity;return this.group&&(e*=this.group.getObjectOpacity()),e},_set:function(e,i){var s="scaleX"===e||"scaleY"===e,n=this[e]!==i,r=!1;return s&&(i=this._constrainScale(i)),"scaleX"===e&&i<0?(this.flipX=!this.flipX,i*=-1):"scaleY"===e&&i<0?(this.flipY=!this.flipY,i*=-1):"shadow"!==e||!i||i instanceof t.Shadow?"dirty"===e&&this.group&&this.group.set("dirty",i):i=new t.Shadow(i),this[e]=i,n&&(r=this.group&&this.group.isOnACache(),this.cacheProperties.indexOf(e)>-1?(this.dirty=!0,r&&this.group.set("dirty",!0)):r&&this.stateProperties.indexOf(e)>-1&&this.group.set("dirty",!0)),this},setOnGroup:function(){},getViewportTransform:function(){return this.canvas&&this.canvas.viewportTransform?this.canvas.viewportTransform:t.iMatrix.concat()},isNotVisible:function(){return 0===this.opacity||!this.width&&!this.height&&0===this.strokeWidth||!this.visible},render:function(e){this.isNotVisible()||this.canvas&&this.canvas.skipOffscreen&&!this.group&&!this.isOnScreen()||(e.save(),this._setupCompositeOperation(e),this.drawSelectionBackground(e),this.transform(e),this._setOpacity(e),this._setShadow(e,this),this.shouldCache()?(this.renderCache(),this.drawCacheOnCanvas(e)):(this._removeCacheCanvas(),this.dirty=!1,this.drawObject(e),this.objectCaching&&this.statefullCache&&this.saveState({propertySet:"cacheProperties"})),e.restore())},renderCache:function(e){e=e||{},this._cacheCanvas&&this._cacheContext||this._createCacheCanvas(),this.isCacheDirty()&&(this.statefullCache&&this.saveState({propertySet:"cacheProperties"}),this.drawObject(this._cacheContext,e.forClipping),this.dirty=!1)},_removeCacheCanvas:function(){this._cacheCanvas=null,this._cacheContext=null,this.cacheWidth=0,this.cacheHeight=0},hasStroke:function(){return this.stroke&&"transparent"!==this.stroke&&0!==this.strokeWidth},hasFill:function(){return this.fill&&"transparent"!==this.fill},needsItsOwnCache:function(){return!("stroke"!==this.paintFirst||!this.hasFill()||!this.hasStroke()||"object"!==typeof this.shadow)||!!this.clipPath},shouldCache:function(){return this.ownCaching=this.needsItsOwnCache()||this.objectCaching&&(!this.group||!this.group.isOnACache()),this.ownCaching},willDrawShadow:function(){return!!this.shadow&&(0!==this.shadow.offsetX||0!==this.shadow.offsetY)},drawClipPathOnCache:function(e,i){if(e.save(),i.inverted?e.globalCompositeOperation="destination-out":e.globalCompositeOperation="destination-in",i.absolutePositioned){var s=t.util.invertTransform(this.calcTransformMatrix());e.transform(s[0],s[1],s[2],s[3],s[4],s[5])}i.transform(e),e.scale(1/i.zoomX,1/i.zoomY),e.drawImage(i._cacheCanvas,-i.cacheTranslationX,-i.cacheTranslationY),e.restore()},drawObject:function(e,t){var i=this.fill,s=this.stroke;t?(this.fill="black",this.stroke="",this._setClippingProperties(e)):this._renderBackground(e),this._render(e),this._drawClipPath(e,this.clipPath),this.fill=i,this.stroke=s},_drawClipPath:function(e,t){t&&(t.canvas=this.canvas,t.shouldCache(),t._transformDone=!0,t.renderCache({forClipping:!0}),this.drawClipPathOnCache(e,t))},drawCacheOnCanvas:function(e){e.scale(1/this.zoomX,1/this.zoomY),e.drawImage(this._cacheCanvas,-this.cacheTranslationX,-this.cacheTranslationY)},isCacheDirty:function(e){if(this.isNotVisible())return!1;if(this._cacheCanvas&&this._cacheContext&&!e&&this._updateCacheCanvas())return!0;if(this.dirty||this.clipPath&&this.clipPath.absolutePositioned||this.statefullCache&&this.hasStateChanged("cacheProperties")){if(this._cacheCanvas&&this._cacheContext&&!e){var t=this.cacheWidth/this.zoomX,i=this.cacheHeight/this.zoomY;this._cacheContext.clearRect(-t/2,-i/2,t,i)}return!0}return!1},_renderBackground:function(e){if(this.backgroundColor){var t=this._getNonTransformedDimensions();e.fillStyle=this.backgroundColor,e.fillRect(-t.x/2,-t.y/2,t.x,t.y),this._removeShadow(e)}},_setOpacity:function(e){this.group&&!this.group._transformDone?e.globalAlpha=this.getObjectOpacity():e.globalAlpha*=this.opacity},_setStrokeStyles:function(e,t){var i=t.stroke;i&&(e.lineWidth=t.strokeWidth,e.lineCap=t.strokeLineCap,e.lineDashOffset=t.strokeDashOffset,e.lineJoin=t.strokeLineJoin,e.miterLimit=t.strokeMiterLimit,i.toLive?"percentage"===i.gradientUnits||i.gradientTransform||i.patternTransform?this._applyPatternForTransformedGradient(e,i):(e.strokeStyle=i.toLive(e,this),this._applyPatternGradientTransform(e,i)):e.strokeStyle=t.stroke)},_setFillStyles:function(e,t){var i=t.fill;i&&(i.toLive?(e.fillStyle=i.toLive(e,this),this._applyPatternGradientTransform(e,t.fill)):e.fillStyle=i)},_setClippingProperties:function(e){e.globalAlpha=1,e.strokeStyle="transparent",e.fillStyle="#000000"},_setLineDash:function(e,t){t&&0!==t.length&&(1&t.length&&t.push.apply(t,t),e.setLineDash(t))},_renderControls:function(e,i){var s,n,r,a=this.getViewportTransform(),l=this.calcTransformMatrix();n="undefined"!==typeof(i=i||{}).hasBorders?i.hasBorders:this.hasBorders,r="undefined"!==typeof i.hasControls?i.hasControls:this.hasControls,l=t.util.multiplyTransformMatrices(a,l),s=t.util.qrDecompose(l),e.save(),e.translate(s.translateX,s.translateY),e.lineWidth=1*this.borderScaleFactor,this.group||(e.globalAlpha=this.isMoving?this.borderOpacityWhenMoving:1),this.flipX&&(s.angle-=180),e.rotate(o(this.group?s.angle:this.angle)),i.forActiveSelection||this.group?n&&this.drawBordersInGroup(e,s,i):n&&this.drawBorders(e,i),r&&this.drawControls(e,i),e.restore()},_setShadow:function(e){if(this.shadow){var i,s=this.shadow,n=this.canvas,r=n&&n.viewportTransform[0]||1,o=n&&n.viewportTransform[3]||1;i=s.nonScaling?{scaleX:1,scaleY:1}:this.getObjectScaling(),n&&n._isRetinaScaling()&&(r*=t.devicePixelRatio,o*=t.devicePixelRatio),e.shadowColor=s.color,e.shadowBlur=s.blur*t.browserShadowBlurConstant*(r+o)*(i.scaleX+i.scaleY)/4,e.shadowOffsetX=s.offsetX*r*i.scaleX,e.shadowOffsetY=s.offsetY*o*i.scaleY}},_removeShadow:function(e){this.shadow&&(e.shadowColor="",e.shadowBlur=e.shadowOffsetX=e.shadowOffsetY=0)},_applyPatternGradientTransform:function(e,t){if(!t||!t.toLive)return{offsetX:0,offsetY:0};var i=t.gradientTransform||t.patternTransform,s=-this.width/2+t.offsetX||0,n=-this.height/2+t.offsetY||0;return"percentage"===t.gradientUnits?e.transform(this.width,0,0,this.height,s,n):e.transform(1,0,0,1,s,n),i&&e.transform(i[0],i[1],i[2],i[3],i[4],i[5]),{offsetX:s,offsetY:n}},_renderPaintInOrder:function(e){"stroke"===this.paintFirst?(this._renderStroke(e),this._renderFill(e)):(this._renderFill(e),this._renderStroke(e))},_render:function(){},_renderFill:function(e){this.fill&&(e.save(),this._setFillStyles(e,this),"evenodd"===this.fillRule?e.fill("evenodd"):e.fill(),e.restore())},_renderStroke:function(e){if(this.stroke&&0!==this.strokeWidth){if(this.shadow&&!this.shadow.affectStroke&&this._removeShadow(e),e.save(),this.strokeUniform&&this.group){var t=this.getObjectScaling();e.scale(1/t.scaleX,1/t.scaleY)}else this.strokeUniform&&e.scale(1/this.scaleX,1/this.scaleY);this._setLineDash(e,this.strokeDashArray),this._setStrokeStyles(e,this),e.stroke(),e.restore()}},_applyPatternForTransformedGradient:function(e,i){var s,n=this._limitCacheSize(this._getCacheCanvasDimensions()),r=t.util.createCanvasElement(),o=this.canvas.getRetinaScaling(),a=n.x/this.scaleX/o,l=n.y/this.scaleY/o;r.width=Math.ceil(a),r.height=Math.ceil(l),(s=r.getContext("2d")).beginPath(),s.moveTo(0,0),s.lineTo(a,0),s.lineTo(a,l),s.lineTo(0,l),s.closePath(),s.translate(a/2,l/2),s.scale(n.zoomX/this.scaleX/o,n.zoomY/this.scaleY/o),this._applyPatternGradientTransform(s,i),s.fillStyle=i.toLive(e),s.fill(),e.translate(-this.width/2-this.strokeWidth/2,-this.height/2-this.strokeWidth/2),e.scale(o*this.scaleX/n.zoomX,o*this.scaleY/n.zoomY),e.strokeStyle=s.createPattern(r,"no-repeat")},_findCenterFromElement:function(){return{x:this.left+this.width/2,y:this.top+this.height/2}},_assignTransformMatrixProps:function(){if(this.transformMatrix){var e=t.util.qrDecompose(this.transformMatrix);this.flipX=!1,this.flipY=!1,this.set("scaleX",e.scaleX),this.set("scaleY",e.scaleY),this.angle=e.angle,this.skewX=e.skewX,this.skewY=0}},_removeTransformMatrix:function(e){var i=this._findCenterFromElement();this.transformMatrix&&(this._assignTransformMatrixProps(),i=t.util.transformPoint(i,this.transformMatrix)),this.transformMatrix=null,e&&(this.scaleX*=e.scaleX,this.scaleY*=e.scaleY,this.cropX=e.cropX,this.cropY=e.cropY,i.x+=e.offsetLeft,i.y+=e.offsetTop,this.width=e.width,this.height=e.height),this.setPositionByOrigin(i,"center","center")},clone:function(e,i){var s=this.toObject(i);this.constructor.fromObject?this.constructor.fromObject(s,e):t.Object._fromObject("Object",s,e)},cloneAsImage:function(e,i){var s=this.toCanvasElement(i);return e&&e(new t.Image(s)),this},toCanvasElement:function(e){e||(e={});var i=t.util,s=i.saveObjectTransform(this),n=this.group,r=this.shadow,o=Math.abs,a=(e.multiplier||1)*(e.enableRetinaScaling?t.devicePixelRatio:1);delete this.group,e.withoutTransform&&i.resetObjectTransform(this),e.withoutShadow&&(this.shadow=null);var l,c,h,d,u=t.util.createCanvasElement(),g=this.getBoundingRect(!0,!0),p=this.shadow,m={x:0,y:0};p&&(c=p.blur,l=p.nonScaling?{scaleX:1,scaleY:1}:this.getObjectScaling(),m.x=2*Math.round(o(p.offsetX)+c)*o(l.scaleX),m.y=2*Math.round(o(p.offsetY)+c)*o(l.scaleY)),h=g.width+m.x,d=g.height+m.y,u.width=Math.ceil(h),u.height=Math.ceil(d);var f=new t.StaticCanvas(u,{enableRetinaScaling:!1,renderOnAddRemove:!1,skipOffscreen:!1});"jpeg"===e.format&&(f.backgroundColor="#fff"),this.setPositionByOrigin(new t.Point(f.width/2,f.height/2),"center","center");var _=this.canvas;f.add(this);var v=f.toCanvasElement(a||1,e);return this.shadow=r,this.set("canvas",_),n&&(this.group=n),this.set(s).setCoords(),f._objects=[],f.dispose(),f=null,v},toDataURL:function(e){return e||(e={}),t.util.toDataURL(this.toCanvasElement(e),e.format||"png",e.quality||1)},isType:function(e){return arguments.length>1?Array.from(arguments).includes(this.type):this.type===e},complexity:function(){return 1},toJSON:function(e){return this.toObject(e)},rotate:function(e){var t=("center"!==this.originX||"center"!==this.originY)&&this.centeredRotation;return t&&this._setOriginToCenter(),this.set("angle",e),t&&this._resetOrigin(),this},centerH:function(){return this.canvas&&this.canvas.centerObjectH(this),this},viewportCenterH:function(){return this.canvas&&this.canvas.viewportCenterObjectH(this),this},centerV:function(){return this.canvas&&this.canvas.centerObjectV(this),this},viewportCenterV:function(){return this.canvas&&this.canvas.viewportCenterObjectV(this),this},center:function(){return this.canvas&&this.canvas.centerObject(this),this},viewportCenter:function(){return this.canvas&&this.canvas.viewportCenterObject(this),this},getLocalPointer:function(e,i){i=i||this.canvas.getPointer(e);var s=new t.Point(i.x,i.y),n=this._getLeftTopCoords();return this.angle&&(s=t.util.rotatePoint(s,n,o(-this.angle))),{x:s.x-n.x,y:s.y-n.y}},_setupCompositeOperation:function(e){this.globalCompositeOperation&&(e.globalCompositeOperation=this.globalCompositeOperation)},dispose:function(){t.runningAnimations&&t.runningAnimations.cancelByTarget(this)}}),t.util.createAccessors&&t.util.createAccessors(t.Object),i(t.Object.prototype,t.Observable),t.Object.NUM_FRACTION_DIGITS=2,t.Object.ENLIVEN_PROPS=["clipPath"],t.Object._fromObject=function(e,i,n,r){var o=t[e];i=s(i,!0),t.util.enlivenPatterns([i.fill,i.stroke],(function(e){"undefined"!==typeof e[0]&&(i.fill=e[0]),"undefined"!==typeof e[1]&&(i.stroke=e[1]),t.util.enlivenObjectEnlivables(i,i,(function(){var e=r?new o(i[r],i):new o(i);n&&n(e)}))}))},t.Object.__uid=0)}(t),function(){var e=n.util.degreesToRadians,t={left:-.5,center:0,right:.5},i={top:-.5,center:0,bottom:.5};n.util.object.extend(n.Object.prototype,{translateToGivenOrigin:function(e,s,r,o,a){var l,c,h,d=e.x,u=e.y;return"string"===typeof s?s=t[s]:s-=.5,"string"===typeof o?o=t[o]:o-=.5,"string"===typeof r?r=i[r]:r-=.5,"string"===typeof a?a=i[a]:a-=.5,c=a-r,((l=o-s)||c)&&(h=this._getTransformedDimensions(),d=e.x+l*h.x,u=e.y+c*h.y),new n.Point(d,u)},translateToCenterPoint:function(t,i,s){var r=this.translateToGivenOrigin(t,i,s,"center","center");return this.angle?n.util.rotatePoint(r,t,e(this.angle)):r},translateToOriginPoint:function(t,i,s){var r=this.translateToGivenOrigin(t,"center","center",i,s);return this.angle?n.util.rotatePoint(r,t,e(this.angle)):r},getCenterPoint:function(){var e=new n.Point(this.left,this.top);return this.translateToCenterPoint(e,this.originX,this.originY)},getPointByOrigin:function(e,t){var i=this.getCenterPoint();return this.translateToOriginPoint(i,e,t)},toLocalPoint:function(t,i,s){var r,o,a=this.getCenterPoint();return r="undefined"!==typeof i&&"undefined"!==typeof s?this.translateToGivenOrigin(a,"center","center",i,s):new n.Point(this.left,this.top),o=new n.Point(t.x,t.y),this.angle&&(o=n.util.rotatePoint(o,a,-e(this.angle))),o.subtractEquals(r)},setPositionByOrigin:function(e,t,i){var s=this.translateToCenterPoint(e,t,i),n=this.translateToOriginPoint(s,this.originX,this.originY);this.set("left",n.x),this.set("top",n.y)},adjustPosition:function(i){var s,r,o=e(this.angle),a=this.getScaledWidth(),l=n.util.cos(o)*a,c=n.util.sin(o)*a;s="string"===typeof this.originX?t[this.originX]:this.originX-.5,r="string"===typeof i?t[i]:i-.5,this.left+=l*(r-s),this.top+=c*(r-s),this.setCoords(),this.originX=i},_setOriginToCenter:function(){this._originalOriginX=this.originX,this._originalOriginY=this.originY;var e=this.getCenterPoint();this.originX="center",this.originY="center",this.left=e.x,this.top=e.y},_resetOrigin:function(){var e=this.translateToOriginPoint(this.getCenterPoint(),this._originalOriginX,this._originalOriginY);this.originX=this._originalOriginX,this.originY=this._originalOriginY,this.left=e.x,this.top=e.y,this._originalOriginX=null,this._originalOriginY=null},_getLeftTopCoords:function(){return this.translateToOriginPoint(this.getCenterPoint(),"left","top")}})}(),function(){var e=n.util,t=e.degreesToRadians,i=e.multiplyTransformMatrices,s=e.transformPoint;e.object.extend(n.Object.prototype,{oCoords:null,aCoords:null,lineCoords:null,ownMatrixCache:null,matrixCache:null,controls:{},_getCoords:function(e,t){return t?e?this.calcACoords():this.calcLineCoords():(this.aCoords&&this.lineCoords||this.setCoords(!0),e?this.aCoords:this.lineCoords)},getCoords:function(e,t){return i=this._getCoords(e,t),[new n.Point(i.tl.x,i.tl.y),new n.Point(i.tr.x,i.tr.y),new n.Point(i.br.x,i.br.y),new n.Point(i.bl.x,i.bl.y)];var i},intersectsWithRect:function(e,t,i,s){var r=this.getCoords(i,s);return"Intersection"===n.Intersection.intersectPolygonRectangle(r,e,t).status},intersectsWithObject:function(e,t,i){return"Intersection"===n.Intersection.intersectPolygonPolygon(this.getCoords(t,i),e.getCoords(t,i)).status||e.isContainedWithinObject(this,t,i)||this.isContainedWithinObject(e,t,i)},isContainedWithinObject:function(e,t,i){for(var s=this.getCoords(t,i),n=t?e.aCoords:e.lineCoords,r=0,o=e._getImageLines(n);r<4;r++)if(!e.containsPoint(s[r],o))return!1;return!0},isContainedWithinRect:function(e,t,i,s){var n=this.getBoundingRect(i,s);return n.left>=e.x&&n.left+n.width<=t.x&&n.top>=e.y&&n.top+n.height<=t.y},containsPoint:function(e,t,i,s){var n=this._getCoords(i,s),r=(t=t||this._getImageLines(n),this._findCrossPoints(e,t));return 0!==r&&r%2===1},isOnScreen:function(e){if(!this.canvas)return!1;var t=this.canvas.vptCoords.tl,i=this.canvas.vptCoords.br;return!!this.getCoords(!0,e).some((function(e){return e.x<=i.x&&e.x>=t.x&&e.y<=i.y&&e.y>=t.y}))||(!!this.intersectsWithRect(t,i,!0,e)||this._containsCenterOfCanvas(t,i,e))},_containsCenterOfCanvas:function(e,t,i){var s={x:(e.x+t.x)/2,y:(e.y+t.y)/2};return!!this.containsPoint(s,null,!0,i)},isPartiallyOnScreen:function(e){if(!this.canvas)return!1;var t=this.canvas.vptCoords.tl,i=this.canvas.vptCoords.br;return!!this.intersectsWithRect(t,i,!0,e)||this.getCoords(!0,e).every((function(e){return(e.x>=i.x||e.x<=t.x)&&(e.y>=i.y||e.y<=t.y)}))&&this._containsCenterOfCanvas(t,i,e)},_getImageLines:function(e){return{topline:{o:e.tl,d:e.tr},rightline:{o:e.tr,d:e.br},bottomline:{o:e.br,d:e.bl},leftline:{o:e.bl,d:e.tl}}},_findCrossPoints:function(e,t){var i,s,n,r=0;for(var o in t)if(!((n=t[o]).o.y=e.y&&n.d.y>=e.y)&&(n.o.x===n.d.x&&n.o.x>=e.x?s=n.o.x:(i=(n.d.y-n.o.y)/(n.d.x-n.o.x),s=-(e.y-0*e.x-(n.o.y-i*n.o.x))/(0-i)),s>=e.x&&(r+=1),2===r))break;return r},getBoundingRect:function(t,i){var s=this.getCoords(t,i);return e.makeBoundingBoxFromPoints(s)},getScaledWidth:function(){return this._getTransformedDimensions().x},getScaledHeight:function(){return this._getTransformedDimensions().y},_constrainScale:function(e){return Math.abs(e)\n')}},toSVG:function(e){return this._createBaseSVGMarkup(this._toSVG(e),{reviver:e})},toClipPathSVG:function(e){return"\t"+this._createBaseClipPathSVGMarkup(this._toSVG(e),{reviver:e})},_createBaseClipPathSVGMarkup:function(e,t){var i=(t=t||{}).reviver,s=t.additionalTransform||"",n=[this.getSvgTransform(!0,s),this.getSvgCommons()].join(""),r=e.indexOf("COMMON_PARTS");return e[r]=n,i?i(e.join("")):e.join("")},_createBaseSVGMarkup:function(e,t){var i,s,r=(t=t||{}).noStyle,o=t.reviver,a=r?"":'style="'+this.getSvgStyles()+'" ',l=t.withShadow?'style="'+this.getSvgFilter()+'" ':"",c=this.clipPath,h=this.strokeUniform?'vector-effect="non-scaling-stroke" ':"",d=c&&c.absolutePositioned,u=this.stroke,g=this.fill,p=this.shadow,m=[],f=e.indexOf("COMMON_PARTS"),_=t.additionalTransform;return c&&(c.clipPathId="CLIPPATH_"+n.Object.__uid++,s='\n'+c.toClipPathSVG(o)+"\n"),d&&m.push("\n"),m.push("\n"),i=[a,h,r?"":this.addPaintOrder()," ",_?'transform="'+_+'" ':""].join(""),e[f]=i,g&&g.toLive&&m.push(g.toSVG(this)),u&&u.toLive&&m.push(u.toSVG(this)),p&&m.push(p.toSVG(this)),c&&m.push(s),m.push(e.join("")),m.push("\n"),d&&m.push("\n"),o?o(m.join("")):m.join("")},addPaintOrder:function(){return"fill"!==this.paintFirst?' paint-order="'+this.paintFirst+'" ':""}})}(),function(){var e=n.util.object.extend,t="stateProperties";function i(t,i,s){var n={};s.forEach((function(e){n[e]=t[e]})),e(t[i],n,!0)}function s(e,t,i){if(e===t)return!0;if(Array.isArray(e)){if(!Array.isArray(t)||e.length!==t.length)return!1;for(var n=0,r=e.length;n=0;l--)if(n=a[l],this.isControlVisible(n)&&(s=this._getImageLines(t?this.oCoords[n].touchCorner:this.oCoords[n].corner),0!==(i=this._findCrossPoints({x:r,y:o},s))&&i%2===1))return this.__corner=n,n;return!1},forEachControl:function(e){for(var t in this.controls)e(this.controls[t],t,this)},_setCornerCoords:function(){var e=this.oCoords;for(var t in e){var i=this.controls[t];e[t].corner=i.calcCornerCoords(this.angle,this.cornerSize,e[t].x,e[t].y,!1),e[t].touchCorner=i.calcCornerCoords(this.angle,this.touchCornerSize,e[t].x,e[t].y,!0)}},drawSelectionBackground:function(t){if(!this.selectionBackgroundColor||this.canvas&&!this.canvas.interactive||this.canvas&&this.canvas._activeObject!==this)return this;t.save();var i=this.getCenterPoint(),s=this._calculateCurrentDimensions(),n=this.canvas.viewportTransform;return t.translate(i.x,i.y),t.scale(1/n[0],1/n[3]),t.rotate(e(this.angle)),t.fillStyle=this.selectionBackgroundColor,t.fillRect(-s.x/2,-s.y/2,s.x,s.y),t.restore(),this},drawBorders:function(e,t){t=t||{};var i=this._calculateCurrentDimensions(),s=this.borderScaleFactor,n=i.x+s,r=i.y+s,o="undefined"!==typeof t.hasControls?t.hasControls:this.hasControls,a=!1;return e.save(),e.strokeStyle=t.borderColor||this.borderColor,this._setLineDash(e,t.borderDashArray||this.borderDashArray),e.strokeRect(-n/2,-r/2,n,r),o&&(e.beginPath(),this.forEachControl((function(t,i,s){t.withConnection&&t.getVisibility(s,i)&&(a=!0,e.moveTo(t.x*n,t.y*r),e.lineTo(t.x*n+t.offsetX,t.y*r+t.offsetY))})),a&&e.stroke()),e.restore(),this},drawBordersInGroup:function(e,t,i){i=i||{};var s=n.util.sizeAfterTransform(this.width,this.height,t),r=this.strokeWidth,o=this.strokeUniform,a=this.borderScaleFactor,l=s.x+r*(o?this.canvas.getZoom():t.scaleX)+a,c=s.y+r*(o?this.canvas.getZoom():t.scaleY)+a;return e.save(),this._setLineDash(e,i.borderDashArray||this.borderDashArray),e.strokeStyle=i.borderColor||this.borderColor,e.strokeRect(-l/2,-c/2,l,c),e.restore(),this},drawControls:function(e,t){t=t||{},e.save();var i,s,r=1;return this.canvas&&(r=this.canvas.getRetinaScaling()),e.setTransform(r,0,0,r,0,0),e.strokeStyle=e.fillStyle=t.cornerColor||this.cornerColor,this.transparentCorners||(e.strokeStyle=t.cornerStrokeColor||this.cornerStrokeColor),this._setLineDash(e,t.cornerDashArray||this.cornerDashArray),this.setCoords(),this.group&&(i=this.group.calcTransformMatrix()),this.forEachControl((function(r,o,a){s=a.oCoords[o],r.getVisibility(a,o)&&(i&&(s=n.util.transformPoint(s,i)),r.render(e,s.x,s.y,t,a))})),e.restore(),this},isControlVisible:function(e){return this.controls[e]&&this.controls[e].getVisibility(this,e)},setControlVisible:function(e,t){return this._controlsVisibility||(this._controlsVisibility={}),this._controlsVisibility[e]=t,this},setControlsVisibility:function(e){for(var t in e||(e={}),e)this.setControlVisible(t,e[t]);return this},onDeselect:function(){},onSelect:function(){}})}(),n.util.object.extend(n.StaticCanvas.prototype,{FX_DURATION:500,fxCenterObjectH:function(e,t){var i=function(){},s=(t=t||{}).onComplete||i,r=t.onChange||i,o=this;return n.util.animate({target:this,startValue:e.left,endValue:this.getCenterPoint().x,duration:this.FX_DURATION,onChange:function(t){e.set("left",t),o.requestRenderAll(),r()},onComplete:function(){e.setCoords(),s()}})},fxCenterObjectV:function(e,t){var i=function(){},s=(t=t||{}).onComplete||i,r=t.onChange||i,o=this;return n.util.animate({target:this,startValue:e.top,endValue:this.getCenterPoint().y,duration:this.FX_DURATION,onChange:function(t){e.set("top",t),o.requestRenderAll(),r()},onComplete:function(){e.setCoords(),s()}})},fxRemove:function(e,t){var i=function(){},s=(t=t||{}).onComplete||i,r=t.onChange||i,o=this;return n.util.animate({target:this,startValue:e.opacity,endValue:0,duration:this.FX_DURATION,onChange:function(t){e.set("opacity",t),o.requestRenderAll(),r()},onComplete:function(){o.remove(e),s()}})}}),n.util.object.extend(n.Object.prototype,{animate:function(){if(arguments[0]&&"object"===typeof arguments[0]){var e,t,i=[],s=[];for(e in arguments[0])i.push(e);for(var n=0,r=i.length;n-1||r&&o.colorProperties.indexOf(r[1])>-1,l=r?this.get(r[0])[r[1]]:this.get(e);"from"in i||(i.from=l),a||(t=~t.indexOf("=")?l+parseFloat(t.replace("=","")):parseFloat(t));var c={target:this,startValue:i.from,endValue:t,byValue:i.by,easing:i.easing,duration:i.duration,abort:i.abort&&function(e,t,s){return i.abort.call(o,e,t,s)},onChange:function(t,n,a){r?o[r[0]][r[1]]=t:o.set(e,t),s||i.onChange&&i.onChange(t,n,a)},onComplete:function(e,t,n){s||(o.setCoords(),i.onComplete&&i.onComplete(e,t,n))}};return a?n.util.animateColor(c.startValue,c.endValue,c.duration,c):n.util.animate(c)}}),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.object.extend,s=t.util.object.clone,n={x1:1,x2:1,y1:1,y2:1};function r(e,t){var i=e.origin,s=e.axis1,n=e.axis2,r=e.dimension,o=t.nearest,a=t.center,l=t.farthest;return function(){switch(this.get(i)){case o:return Math.min(this.get(s),this.get(n));case a:return Math.min(this.get(s),this.get(n))+.5*this.get(r);case l:return Math.max(this.get(s),this.get(n))}}}t.Line?t.warn("fabric.Line is already defined"):(t.Line=t.util.createClass(t.Object,{type:"line",x1:0,y1:0,x2:0,y2:0,cacheProperties:t.Object.prototype.cacheProperties.concat("x1","x2","y1","y2"),initialize:function(e,t){e||(e=[0,0,0,0]),this.callSuper("initialize",t),this.set("x1",e[0]),this.set("y1",e[1]),this.set("x2",e[2]),this.set("y2",e[3]),this._setWidthHeight(t)},_setWidthHeight:function(e){e||(e={}),this.width=Math.abs(this.x2-this.x1),this.height=Math.abs(this.y2-this.y1),this.left="left"in e?e.left:this._getLeftToOriginX(),this.top="top"in e?e.top:this._getTopToOriginY()},_set:function(e,t){return this.callSuper("_set",e,t),"undefined"!==typeof n[e]&&this._setWidthHeight(),this},_getLeftToOriginX:r({origin:"originX",axis1:"x1",axis2:"x2",dimension:"width"},{nearest:"left",center:"center",farthest:"right"}),_getTopToOriginY:r({origin:"originY",axis1:"y1",axis2:"y2",dimension:"height"},{nearest:"top",center:"center",farthest:"bottom"}),_render:function(e){e.beginPath();var t=this.calcLinePoints();e.moveTo(t.x1,t.y1),e.lineTo(t.x2,t.y2),e.lineWidth=this.strokeWidth;var i=e.strokeStyle;e.strokeStyle=this.stroke||e.fillStyle,this.stroke&&this._renderStroke(e),e.strokeStyle=i},_findCenterFromElement:function(){return{x:(this.x1+this.x2)/2,y:(this.y1+this.y2)/2}},toObject:function(e){return i(this.callSuper("toObject",e),this.calcLinePoints())},_getNonTransformedDimensions:function(){var e=this.callSuper("_getNonTransformedDimensions");return"butt"===this.strokeLineCap&&(0===this.width&&(e.y-=this.strokeWidth),0===this.height&&(e.x-=this.strokeWidth)),e},calcLinePoints:function(){var e=this.x1<=this.x2?-1:1,t=this.y1<=this.y2?-1:1,i=e*this.width*.5,s=t*this.height*.5;return{x1:i,x2:e*this.width*-.5,y1:s,y2:t*this.height*-.5}},_toSVG:function(){var e=this.calcLinePoints();return["\n']}}),t.Line.ATTRIBUTE_NAMES=t.SHARED_ATTRIBUTES.concat("x1 y1 x2 y2".split(" ")),t.Line.fromElement=function(e,s,n){n=n||{};var r=t.parseAttributes(e,t.Line.ATTRIBUTE_NAMES),o=[r.x1||0,r.y1||0,r.x2||0,r.y2||0];s(new t.Line(o,i(r,n)))},t.Line.fromObject=function(e,i){var n=s(e,!0);n.points=[e.x1,e.y1,e.x2,e.y2],t.Object._fromObject("Line",n,(function(e){delete e.points,i&&i(e)}),"points")})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.degreesToRadians;t.Circle?t.warn("fabric.Circle is already defined."):(t.Circle=t.util.createClass(t.Object,{type:"circle",radius:0,startAngle:0,endAngle:360,cacheProperties:t.Object.prototype.cacheProperties.concat("radius","startAngle","endAngle"),_set:function(e,t){return this.callSuper("_set",e,t),"radius"===e&&this.setRadius(t),this},toObject:function(e){return this.callSuper("toObject",["radius","startAngle","endAngle"].concat(e))},_toSVG:function(){var e,s=(this.endAngle-this.startAngle)%360;if(0===s)e=["\n'];else{var n=i(this.startAngle),r=i(this.endAngle),o=this.radius;e=['180?"1":"0")+" 1"," "+t.util.cos(r)*o+" "+t.util.sin(r)*o,'" ',"COMMON_PARTS"," />\n"]}return e},_render:function(e){e.beginPath(),e.arc(0,0,this.radius,i(this.startAngle),i(this.endAngle),!1),this._renderPaintInOrder(e)},getRadiusX:function(){return this.get("radius")*this.get("scaleX")},getRadiusY:function(){return this.get("radius")*this.get("scaleY")},setRadius:function(e){return this.radius=e,this.set("width",2*e).set("height",2*e)}}),t.Circle.ATTRIBUTE_NAMES=t.SHARED_ATTRIBUTES.concat("cx cy r".split(" ")),t.Circle.fromElement=function(e,i){var s,n=t.parseAttributes(e,t.Circle.ATTRIBUTE_NAMES);if(!("radius"in(s=n)&&s.radius>=0))throw new Error("value of `r` attribute is required and can not be negative");n.left=(n.left||0)-n.radius,n.top=(n.top||0)-n.radius,i(new t.Circle(n))},t.Circle.fromObject=function(e,i){t.Object._fromObject("Circle",e,i)})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={});t.Triangle?t.warn("fabric.Triangle is already defined"):(t.Triangle=t.util.createClass(t.Object,{type:"triangle",width:100,height:100,_render:function(e){var t=this.width/2,i=this.height/2;e.beginPath(),e.moveTo(-t,i),e.lineTo(0,-i),e.lineTo(t,i),e.closePath(),this._renderPaintInOrder(e)},_toSVG:function(){var e=this.width/2,t=this.height/2;return["']}}),t.Triangle.fromObject=function(e,i){return t.Object._fromObject("Triangle",e,i)})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=2*Math.PI;t.Ellipse?t.warn("fabric.Ellipse is already defined."):(t.Ellipse=t.util.createClass(t.Object,{type:"ellipse",rx:0,ry:0,cacheProperties:t.Object.prototype.cacheProperties.concat("rx","ry"),initialize:function(e){this.callSuper("initialize",e),this.set("rx",e&&e.rx||0),this.set("ry",e&&e.ry||0)},_set:function(e,t){switch(this.callSuper("_set",e,t),e){case"rx":this.rx=t,this.set("width",2*t);break;case"ry":this.ry=t,this.set("height",2*t)}return this},getRx:function(){return this.get("rx")*this.get("scaleX")},getRy:function(){return this.get("ry")*this.get("scaleY")},toObject:function(e){return this.callSuper("toObject",["rx","ry"].concat(e))},_toSVG:function(){return["\n']},_render:function(e){e.beginPath(),e.save(),e.transform(1,0,0,this.ry/this.rx,0,0),e.arc(0,0,this.rx,0,i,!1),e.restore(),this._renderPaintInOrder(e)}}),t.Ellipse.ATTRIBUTE_NAMES=t.SHARED_ATTRIBUTES.concat("cx cy rx ry".split(" ")),t.Ellipse.fromElement=function(e,i){var s=t.parseAttributes(e,t.Ellipse.ATTRIBUTE_NAMES);s.left=(s.left||0)-s.rx,s.top=(s.top||0)-s.ry,i(new t.Ellipse(s))},t.Ellipse.fromObject=function(e,i){t.Object._fromObject("Ellipse",e,i)})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.object.extend;t.Rect?t.warn("fabric.Rect is already defined"):(t.Rect=t.util.createClass(t.Object,{stateProperties:t.Object.prototype.stateProperties.concat("rx","ry"),type:"rect",rx:0,ry:0,cacheProperties:t.Object.prototype.cacheProperties.concat("rx","ry"),initialize:function(e){this.callSuper("initialize",e),this._initRxRy()},_initRxRy:function(){this.rx&&!this.ry?this.ry=this.rx:this.ry&&!this.rx&&(this.rx=this.ry)},_render:function(e){var t=this.rx?Math.min(this.rx,this.width/2):0,i=this.ry?Math.min(this.ry,this.height/2):0,s=this.width,n=this.height,r=-this.width/2,o=-this.height/2,a=0!==t||0!==i,l=.4477152502;e.beginPath(),e.moveTo(r+t,o),e.lineTo(r+s-t,o),a&&e.bezierCurveTo(r+s-l*t,o,r+s,o+l*i,r+s,o+i),e.lineTo(r+s,o+n-i),a&&e.bezierCurveTo(r+s,o+n-l*i,r+s-l*t,o+n,r+s-t,o+n),e.lineTo(r+t,o+n),a&&e.bezierCurveTo(r+l*t,o+n,r,o+n-l*i,r,o+n-i),e.lineTo(r,o+i),a&&e.bezierCurveTo(r,o+l*i,r+l*t,o,r+t,o),e.closePath(),this._renderPaintInOrder(e)},toObject:function(e){return this.callSuper("toObject",["rx","ry"].concat(e))},_toSVG:function(){return["\n']}}),t.Rect.ATTRIBUTE_NAMES=t.SHARED_ATTRIBUTES.concat("x y rx ry width height".split(" ")),t.Rect.fromElement=function(e,s,n){if(!e)return s(null);n=n||{};var r=t.parseAttributes(e,t.Rect.ATTRIBUTE_NAMES);r.left=r.left||0,r.top=r.top||0,r.height=r.height||0,r.width=r.width||0;var o=new t.Rect(i(n?t.util.object.clone(n):{},r));o.visible=o.visible&&o.width>0&&o.height>0,s(o)},t.Rect.fromObject=function(e,i){return t.Object._fromObject("Rect",e,i)})}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.util.object.extend,s=t.util.array.min,n=t.util.array.max,r=t.util.toFixed,o=t.util.projectStrokeOnPoints;t.Polyline?t.warn("fabric.Polyline is already defined"):(t.Polyline=t.util.createClass(t.Object,{type:"polyline",points:null,exactBoundingBox:!1,cacheProperties:t.Object.prototype.cacheProperties.concat("points"),initialize:function(e,t){t=t||{},this.points=e||[],this.callSuper("initialize",t),this._setPositionDimensions(t)},_projectStrokeOnPoints:function(){return o(this.points,this,!0)},_setPositionDimensions:function(e){var t,i=this._calcDimensions(e),s=this.exactBoundingBox?this.strokeWidth:0;this.width=i.width-s,this.height=i.height-s,e.fromSVG||(t=this.translateToGivenOrigin({x:i.left-this.strokeWidth/2+s/2,y:i.top-this.strokeWidth/2+s/2},"left","top",this.originX,this.originY)),"undefined"===typeof e.left&&(this.left=e.fromSVG?i.left:t.x),"undefined"===typeof e.top&&(this.top=e.fromSVG?i.top:t.y),this.pathOffset={x:i.left+this.width/2+s/2,y:i.top+this.height/2+s/2}},_calcDimensions:function(){var e=this.exactBoundingBox?this._projectStrokeOnPoints():this.points,t=s(e,"x")||0,i=s(e,"y")||0;return{left:t,top:i,width:(n(e,"x")||0)-t,height:(n(e,"y")||0)-i}},toObject:function(e){return i(this.callSuper("toObject",e),{points:this.points.concat()})},_toSVG:function(){for(var e=[],i=this.pathOffset.x,s=this.pathOffset.y,n=t.Object.NUM_FRACTION_DIGITS,o=0,a=this.points.length;o\n']},commonRender:function(e){var t,i=this.points.length,s=this.pathOffset.x,n=this.pathOffset.y;if(!i||isNaN(this.points[i-1].y))return!1;e.beginPath(),e.moveTo(this.points[0].x-s,this.points[0].y-n);for(var r=0;r"},toObject:function(e){return n(this.callSuper("toObject",e),{path:this.path.map((function(e){return e.slice()}))})},toDatalessObject:function(e){var t=this.toObject(["sourcePath"].concat(e));return t.sourcePath&&delete t.path,t},_toSVG:function(){return["\n"]},_getOffsetTransform:function(){var e=t.Object.NUM_FRACTION_DIGITS;return" translate("+o(-this.pathOffset.x,e)+", "+o(-this.pathOffset.y,e)+")"},toClipPathSVG:function(e){var t=this._getOffsetTransform();return"\t"+this._createBaseClipPathSVGMarkup(this._toSVG(),{reviver:e,additionalTransform:t})},toSVG:function(e){var t=this._getOffsetTransform();return this._createBaseSVGMarkup(this._toSVG(),{reviver:e,additionalTransform:t})},complexity:function(){return this.path.length},_calcDimensions:function(){for(var e,n,r=[],o=[],a=0,l=0,c=0,h=0,d=0,u=this.path.length;d"},addWithUpdate:function(e){var i=!!this.group;return this._restoreObjectsState(),t.util.resetObjectTransform(this),e&&(i&&t.util.removeTransformFromObject(e,this.group.calcTransformMatrix()),this._objects.push(e),e.group=this,e._set("canvas",this.canvas)),this._calcBounds(),this._updateObjectsCoords(),this.dirty=!0,i?this.group.addWithUpdate():this.setCoords(),this},removeWithUpdate:function(e){return this._restoreObjectsState(),t.util.resetObjectTransform(this),this.remove(e),this._calcBounds(),this._updateObjectsCoords(),this.setCoords(),this.dirty=!0,this},_onObjectAdded:function(e){this.dirty=!0,e.group=this,e._set("canvas",this.canvas)},_onObjectRemoved:function(e){this.dirty=!0,delete e.group},_set:function(e,i){var s=this._objects.length;if(this.useSetOnGroup)for(;s--;)this._objects[s].setOnGroup(e,i);if("canvas"===e)for(;s--;)this._objects[s]._set(e,i);t.Object.prototype._set.call(this,e,i)},toObject:function(e){var i=this.includeDefaultValues,s=this._objects.filter((function(e){return!e.excludeFromExport})).map((function(t){var s=t.includeDefaultValues;t.includeDefaultValues=i;var n=t.toObject(e);return t.includeDefaultValues=s,n})),n=t.Object.prototype.toObject.call(this,e);return n.objects=s,n},toDatalessObject:function(e){var i,s=this.sourcePath;if(s)i=s;else{var n=this.includeDefaultValues;i=this._objects.map((function(t){var i=t.includeDefaultValues;t.includeDefaultValues=n;var s=t.toDatalessObject(e);return t.includeDefaultValues=i,s}))}var r=t.Object.prototype.toDatalessObject.call(this,e);return r.objects=i,r},render:function(e){this._transformDone=!0,this.callSuper("render",e),this._transformDone=!1},shouldCache:function(){var e=t.Object.prototype.shouldCache.call(this);if(e)for(var i=0,s=this._objects.length;i\n"],i=0,s=this._objects.length;i\n"),t},getSvgStyles:function(){var e="undefined"!==typeof this.opacity&&1!==this.opacity?"opacity: "+this.opacity+";":"",t=this.visible?"":" visibility: hidden;";return[e,this.getSvgFilter(),t].join("")},toClipPathSVG:function(e){for(var t=[],i=0,s=this._objects.length;i"},shouldCache:function(){return!1},isOnACache:function(){return!1},_renderControls:function(e,t,i){e.save(),e.globalAlpha=this.isMoving?this.borderOpacityWhenMoving:1,"undefined"===typeof(i=i||{}).hasControls&&(i.hasControls=!1),i.forActiveSelection=!0;for(var s=0,n=this._objects.length;s\n','\t\n',"\n"),a=' clip-path="url(#imageCrop_'+c+')" '}if(this.imageSmoothing||(l='" image-rendering="optimizeSpeed'),i.push("\t\n"),this.stroke||this.strokeDashArray){var h=this.fill;this.fill=null,e=["\t\n'],this.fill=h}return t="fill"!==this.paintFirst?t.concat(e,i):t.concat(i,e)},getSrc:function(e){var t=e?this._element:this._originalElement;return t?t.toDataURL?t.toDataURL():this.srcFromAttribute?t.getAttribute("src"):t.src:this.src||""},setSrc:function(e,t,i){return n.util.loadImage(e,(function(e,s){this.setElement(e,i),this._setWidthHeight(),t&&t(this,s)}),this,i&&i.crossOrigin),this},toString:function(){return'#'},applyResizeFilters:function(){var e=this.resizeFilter,t=this.minimumScaleTrigger,i=this.getTotalObjectScaling(),s=i.scaleX,r=i.scaleY,o=this._filteredEl||this._originalElement;if(this.group&&this.set("dirty",!0),!e||s>t&&r>t)return this._element=o,this._filterScalingX=1,this._filterScalingY=1,this._lastScaleX=s,void(this._lastScaleY=r);n.filterBackend||(n.filterBackend=n.initFilterBackend());var a=n.util.createCanvasElement(),l=this._filteredEl?this.cacheKey+"_filtered":this.cacheKey,c=o.width,h=o.height;a.width=c,a.height=h,this._element=a,this._lastScaleX=e.scaleX=s,this._lastScaleY=e.scaleY=r,n.filterBackend.applyFilters([e],o,c,h,this._element,l),this._filterScalingX=a.width/this._originalElement.width,this._filterScalingY=a.height/this._originalElement.height},applyFilters:function(e){if(e=(e=e||this.filters||[]).filter((function(e){return e&&!e.isNeutralState()})),this.set("dirty",!0),this.removeTexture(this.cacheKey+"_filtered"),0===e.length)return this._element=this._originalElement,this._filteredEl=null,this._filterScalingX=1,this._filterScalingY=1,this;var t=this._originalElement,i=t.naturalWidth||t.width,s=t.naturalHeight||t.height;if(this._element===this._originalElement){var r=n.util.createCanvasElement();r.width=i,r.height=s,this._element=r,this._filteredEl=r}else this._element=this._filteredEl,this._filteredEl.getContext("2d").clearRect(0,0,i,s),this._lastScaleX=1,this._lastScaleY=1;return n.filterBackend||(n.filterBackend=n.initFilterBackend()),n.filterBackend.applyFilters(e,this._originalElement,i,s,this._element,this.cacheKey),this._originalElement.width===this._element.width&&this._originalElement.height===this._element.height||(this._filterScalingX=this._element.width/this._originalElement.width,this._filterScalingY=this._element.height/this._originalElement.height),this},_render:function(e){n.util.setImageSmoothing(e,this.imageSmoothing),!0!==this.isMoving&&this.resizeFilter&&this._needsResize()&&this.applyResizeFilters(),this._stroke(e),this._renderPaintInOrder(e)},drawCacheOnCanvas:function(e){n.util.setImageSmoothing(e,this.imageSmoothing),n.Object.prototype.drawCacheOnCanvas.call(this,e)},shouldCache:function(){return this.needsItsOwnCache()},_renderFill:function(e){var t=this._element;if(t){var i=this._filterScalingX,s=this._filterScalingY,n=this.width,r=this.height,o=Math.min,a=Math.max,l=a(this.cropX,0),c=a(this.cropY,0),h=t.naturalWidth||t.width,d=t.naturalHeight||t.height,u=l*i,g=c*s,p=o(n*i,h-u),m=o(r*s,d-g),f=-n/2,_=-r/2,v=o(n,h/i-l),C=o(r,d/s-c);t&&e.drawImage(t,u,g,p,m,f,_,v,C)}},_needsResize:function(){var e=this.getTotalObjectScaling();return e.scaleX!==this._lastScaleX||e.scaleY!==this._lastScaleY},_resetWidthHeight:function(){this.set(this.getOriginalSize())},_initElement:function(e,t){this.setElement(n.util.getById(e),t),n.util.addClass(this.getElement(),n.Image.CSS_CANVAS)},_initConfig:function(e){e||(e={}),this.setOptions(e),this._setWidthHeight(e)},_initFilters:function(e,t){e&&e.length?n.util.enlivenObjects(e,(function(e){t&&t(e)}),"fabric.Image.filters"):t&&t()},_setWidthHeight:function(e){e||(e={});var t=this.getElement();this.width=e.width||t.naturalWidth||t.width||0,this.height=e.height||t.naturalHeight||t.height||0},parsePreserveAspectRatioAttribute:function(){var e,t=n.util.parsePreserveAspectRatioAttribute(this.preserveAspectRatio||""),i=this._element.width,s=this._element.height,r=1,o=1,a=0,l=0,c=0,h=0,d=this.width,u=this.height,g={width:d,height:u};return!t||"none"===t.alignX&&"none"===t.alignY?(r=d/i,o=u/s):("meet"===t.meetOrSlice&&(e=(d-i*(r=o=n.util.findScaleToFit(this._element,g)))/2,"Min"===t.alignX&&(a=-e),"Max"===t.alignX&&(a=e),e=(u-s*o)/2,"Min"===t.alignY&&(l=-e),"Max"===t.alignY&&(l=e)),"slice"===t.meetOrSlice&&(e=i-d/(r=o=n.util.findScaleToCover(this._element,g)),"Mid"===t.alignX&&(c=e/2),"Max"===t.alignX&&(c=e),e=s-u/o,"Mid"===t.alignY&&(h=e/2),"Max"===t.alignY&&(h=e),i=d/r,s=u/o)),{width:i,height:s,scaleX:r,scaleY:o,offsetLeft:a,offsetTop:l,cropX:c,cropY:h}}}),n.Image.CSS_CANVAS="canvas-img",n.Image.prototype.getSvgSrc=n.Image.prototype.getSrc,n.Image.fromObject=function(e,t){var i=n.util.object.clone(e);n.util.loadImage(i.src,(function(e,s){s?t&&t(null,!0):n.Image.prototype._initFilters.call(i,i.filters,(function(s){i.filters=s||[],n.Image.prototype._initFilters.call(i,[i.resizeFilter],(function(s){i.resizeFilter=s[0],n.util.enlivenObjectEnlivables(i,i,(function(){var s=new n.Image(e,i);t(s,!1)}))}))}))}),null,i.crossOrigin)},n.Image.fromURL=function(e,t,i){n.util.loadImage(e,(function(e,s){t&&t(new n.Image(e,i),s)}),null,i&&i.crossOrigin)},n.Image.ATTRIBUTE_NAMES=n.SHARED_ATTRIBUTES.concat("x y width height preserveAspectRatio xlink:href crossOrigin image-rendering".split(" ")),n.Image.fromElement=function(e,i,s){var r=n.parseAttributes(e,n.Image.ATTRIBUTE_NAMES);n.Image.fromURL(r["xlink:href"],i,t(s?n.util.object.clone(s):{},r))})}(t),n.util.object.extend(n.Object.prototype,{_getAngleValueForStraighten:function(){var e=this.angle%360;return e>0?90*Math.round((e-1)/90):90*Math.round(e/90)},straighten:function(){return this.rotate(this._getAngleValueForStraighten())},fxStraighten:function(e){var t=function(){},i=(e=e||{}).onComplete||t,s=e.onChange||t,r=this;return n.util.animate({target:this,startValue:this.get("angle"),endValue:this._getAngleValueForStraighten(),duration:this.FX_DURATION,onChange:function(e){r.rotate(e),s()},onComplete:function(){r.setCoords(),i()}})}}),n.util.object.extend(n.StaticCanvas.prototype,{straightenObject:function(e){return e.straighten(),this.requestRenderAll(),this},fxStraightenObject:function(e){return e.fxStraighten({onChange:this.requestRenderAllBound})}}),function(){"use strict";function e(e,t){var i="precision "+t+" float;\nvoid main(){}",s=e.createShader(e.FRAGMENT_SHADER);return e.shaderSource(s,i),e.compileShader(s),!!e.getShaderParameter(s,e.COMPILE_STATUS)}function t(e){e&&e.tileSize&&(this.tileSize=e.tileSize),this.setupGLContext(this.tileSize,this.tileSize),this.captureGPUInfo()}n.isWebglSupported=function(t){if(n.isLikelyNode)return!1;t=t||n.WebglFilterBackend.prototype.tileSize;var i=document.createElement("canvas"),s=i.getContext("webgl")||i.getContext("experimental-webgl"),r=!1;if(s){n.maxTextureSize=s.getParameter(s.MAX_TEXTURE_SIZE),r=n.maxTextureSize>=t;for(var o=["highp","mediump","lowp"],a=0;a<3;a++)if(e(s,o[a])){n.webGlPrecision=o[a];break}}return this.isSupported=r,r},n.WebglFilterBackend=t,t.prototype={tileSize:2048,resources:{},setupGLContext:function(e,t){this.dispose(),this.createWebGLCanvas(e,t),this.aPosition=new Float32Array([0,0,0,1,1,0,1,1]),this.chooseFastestCopyGLTo2DMethod(e,t)},chooseFastestCopyGLTo2DMethod:function(e,t){var i,s="undefined"!==typeof window.performance;try{new ImageData(1,1),i=!0}catch(p){i=!1}var r="undefined"!==typeof ArrayBuffer,l="undefined"!==typeof Uint8ClampedArray;if(s&&i&&r&&l){var c=n.util.createCanvasElement(),h=new ArrayBuffer(e*t*4);if(n.forceGLPutImageData)return this.imageBuffer=h,void(this.copyGLTo2D=a);var d,u,g={imageBuffer:h,destinationWidth:e,destinationHeight:t,targetCanvas:c};c.width=e,c.height=t,d=window.performance.now(),o.call(g,this.gl,g),u=window.performance.now()-d,d=window.performance.now(),a.call(g,this.gl,g),u>window.performance.now()-d?(this.imageBuffer=h,this.copyGLTo2D=a):this.copyGLTo2D=o}},createWebGLCanvas:function(e,t){var i=n.util.createCanvasElement();i.width=e,i.height=t;var s={alpha:!0,premultipliedAlpha:!1,depth:!1,stencil:!1,antialias:!1},r=i.getContext("webgl",s);r||(r=i.getContext("experimental-webgl",s)),r&&(r.clearColor(0,0,0,0),this.canvas=i,this.gl=r)},applyFilters:function(e,t,i,s,n,r){var o,a=this.gl;r&&(o=this.getCachedTexture(r,t));var l={originalWidth:t.width||t.originalWidth,originalHeight:t.height||t.originalHeight,sourceWidth:i,sourceHeight:s,destinationWidth:i,destinationHeight:s,context:a,sourceTexture:this.createTexture(a,i,s,!o&&t),targetTexture:this.createTexture(a,i,s),originalTexture:o||this.createTexture(a,i,s,!o&&t),passes:e.length,webgl:!0,aPosition:this.aPosition,programCache:this.programCache,pass:0,filterBackend:this,targetCanvas:n},c=a.createFramebuffer();return a.bindFramebuffer(a.FRAMEBUFFER,c),e.forEach((function(e){e&&e.applyTo(l)})),function(e){var t=e.targetCanvas,i=t.width,s=t.height,n=e.destinationWidth,r=e.destinationHeight;i===n&&s===r||(t.width=n,t.height=r)}(l),this.copyGLTo2D(a,l),a.bindTexture(a.TEXTURE_2D,null),a.deleteTexture(l.sourceTexture),a.deleteTexture(l.targetTexture),a.deleteFramebuffer(c),n.getContext("2d").setTransform(1,0,0,1,0,0),l},dispose:function(){this.canvas&&(this.canvas=null,this.gl=null),this.clearWebGLCaches()},clearWebGLCaches:function(){this.programCache={},this.textureCache={}},createTexture:function(e,t,i,s,n){var r=e.createTexture();return e.bindTexture(e.TEXTURE_2D,r),e.texParameteri(e.TEXTURE_2D,e.TEXTURE_MAG_FILTER,n||e.NEAREST),e.texParameteri(e.TEXTURE_2D,e.TEXTURE_MIN_FILTER,n||e.NEAREST),e.texParameteri(e.TEXTURE_2D,e.TEXTURE_WRAP_S,e.CLAMP_TO_EDGE),e.texParameteri(e.TEXTURE_2D,e.TEXTURE_WRAP_T,e.CLAMP_TO_EDGE),s?e.texImage2D(e.TEXTURE_2D,0,e.RGBA,e.RGBA,e.UNSIGNED_BYTE,s):e.texImage2D(e.TEXTURE_2D,0,e.RGBA,t,i,0,e.RGBA,e.UNSIGNED_BYTE,null),r},getCachedTexture:function(e,t){if(this.textureCache[e])return this.textureCache[e];var i=this.createTexture(this.gl,t.width,t.height,t);return this.textureCache[e]=i,i},evictCachesForKey:function(e){this.textureCache[e]&&(this.gl.deleteTexture(this.textureCache[e]),delete this.textureCache[e])},copyGLTo2D:o,captureGPUInfo:function(){if(this.gpuInfo)return this.gpuInfo;var e=this.gl,t={renderer:"",vendor:""};if(!e)return t;var i=e.getExtension("WEBGL_debug_renderer_info");if(i){var s=e.getParameter(i.UNMASKED_RENDERER_WEBGL),n=e.getParameter(i.UNMASKED_VENDOR_WEBGL);s&&(t.renderer=s.toLowerCase()),n&&(t.vendor=n.toLowerCase())}return this.gpuInfo=t,t}}}(),function(){"use strict";var e=function(){};function t(){}n.Canvas2dFilterBackend=t,t.prototype={evictCachesForKey:e,dispose:e,clearWebGLCaches:e,resources:{},applyFilters:function(e,t,i,s,n){var r=n.getContext("2d");r.drawImage(t,0,0,i,s);var o={sourceWidth:i,sourceHeight:s,imageData:r.getImageData(0,0,i,s),originalEl:t,originalImageData:r.getImageData(0,0,i,s),canvasEl:n,ctx:r,filterBackend:this};return e.forEach((function(e){e.applyTo(o)})),o.imageData.width===i&&o.imageData.height===s||(n.width=o.imageData.width,n.height=o.imageData.height),r.putImageData(o.imageData,0,0),o}}}(),n.Image=n.Image||{},n.Image.filters=n.Image.filters||{},n.Image.filters.BaseFilter=n.util.createClass({type:"BaseFilter",vertexSource:"attribute vec2 aPosition;\nvarying vec2 vTexCoord;\nvoid main() {\nvTexCoord = aPosition;\ngl_Position = vec4(aPosition * 2.0 - 1.0, 0.0, 1.0);\n}",fragmentSource:"precision highp float;\nvarying vec2 vTexCoord;\nuniform sampler2D uTexture;\nvoid main() {\ngl_FragColor = texture2D(uTexture, vTexCoord);\n}",initialize:function(e){e&&this.setOptions(e)},setOptions:function(e){for(var t in e)this[t]=e[t]},createProgram:function(e,t,i){t=t||this.fragmentSource,i=i||this.vertexSource,"highp"!==n.webGlPrecision&&(t=t.replace(/precision highp float/g,"precision "+n.webGlPrecision+" float"));var s=e.createShader(e.VERTEX_SHADER);if(e.shaderSource(s,i),e.compileShader(s),!e.getShaderParameter(s,e.COMPILE_STATUS))throw new Error("Vertex shader compile error for "+this.type+": "+e.getShaderInfoLog(s));var r=e.createShader(e.FRAGMENT_SHADER);if(e.shaderSource(r,t),e.compileShader(r),!e.getShaderParameter(r,e.COMPILE_STATUS))throw new Error("Fragment shader compile error for "+this.type+": "+e.getShaderInfoLog(r));var o=e.createProgram();if(e.attachShader(o,s),e.attachShader(o,r),e.linkProgram(o),!e.getProgramParameter(o,e.LINK_STATUS))throw new Error('Shader link error for "${this.type}" '+e.getProgramInfoLog(o));var a=this.getAttributeLocations(e,o),l=this.getUniformLocations(e,o)||{};return l.uStepW=e.getUniformLocation(o,"uStepW"),l.uStepH=e.getUniformLocation(o,"uStepH"),{program:o,attributeLocations:a,uniformLocations:l}},getAttributeLocations:function(e,t){return{aPosition:e.getAttribLocation(t,"aPosition")}},getUniformLocations:function(){return{}},sendAttributeData:function(e,t,i){var s=t.aPosition,n=e.createBuffer();e.bindBuffer(e.ARRAY_BUFFER,n),e.enableVertexAttribArray(s),e.vertexAttribPointer(s,2,e.FLOAT,!1,0,0),e.bufferData(e.ARRAY_BUFFER,i,e.STATIC_DRAW)},_setupFrameBuffer:function(e){var t,i,s=e.context;e.passes>1?(t=e.destinationWidth,i=e.destinationHeight,e.sourceWidth===t&&e.sourceHeight===i||(s.deleteTexture(e.targetTexture),e.targetTexture=e.filterBackend.createTexture(s,t,i)),s.framebufferTexture2D(s.FRAMEBUFFER,s.COLOR_ATTACHMENT0,s.TEXTURE_2D,e.targetTexture,0)):(s.bindFramebuffer(s.FRAMEBUFFER,null),s.finish())},_swapTextures:function(e){e.passes--,e.pass++;var t=e.targetTexture;e.targetTexture=e.sourceTexture,e.sourceTexture=t},isNeutralState:function(){var e=this.mainParameter,t=n.Image.filters[this.type].prototype;if(e){if(Array.isArray(t[e])){for(var i=t[e].length;i--;)if(this[e][i]!==t[e][i])return!1;return!0}return t[e]===this[e]}return!1},applyTo:function(e){e.webgl?(this._setupFrameBuffer(e),this.applyToWebGL(e),this._swapTextures(e)):this.applyTo2d(e)},retrieveShader:function(e){return e.programCache.hasOwnProperty(this.type)||(e.programCache[this.type]=this.createProgram(e.context)),e.programCache[this.type]},applyToWebGL:function(e){var t=e.context,i=this.retrieveShader(e);0===e.pass&&e.originalTexture?t.bindTexture(t.TEXTURE_2D,e.originalTexture):t.bindTexture(t.TEXTURE_2D,e.sourceTexture),t.useProgram(i.program),this.sendAttributeData(t,i.attributeLocations,e.aPosition),t.uniform1f(i.uniformLocations.uStepW,1/e.sourceWidth),t.uniform1f(i.uniformLocations.uStepH,1/e.sourceHeight),this.sendUniformData(t,i.uniformLocations),t.viewport(0,0,e.destinationWidth,e.destinationHeight),t.drawArrays(t.TRIANGLE_STRIP,0,4)},bindAdditionalTexture:function(e,t,i){e.activeTexture(i),e.bindTexture(e.TEXTURE_2D,t),e.activeTexture(e.TEXTURE0)},unbindAdditionalTexture:function(e,t){e.activeTexture(t),e.bindTexture(e.TEXTURE_2D,null),e.activeTexture(e.TEXTURE0)},getMainParameter:function(){return this[this.mainParameter]},setMainParameter:function(e){this[this.mainParameter]=e},sendUniformData:function(){},createHelpLayer:function(e){if(!e.helpLayer){var t=document.createElement("canvas");t.width=e.sourceWidth,t.height=e.sourceHeight,e.helpLayer=t}},toObject:function(){var e={type:this.type},t=this.mainParameter;return t&&(e[t]=this[t]),e},toJSON:function(){return this.toObject()}}),n.Image.filters.BaseFilter.fromObject=function(e,t){var i=new n.Image.filters[e.type](e);return t&&t(i),i},function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.Image.filters,s=t.util.createClass;i.ColorMatrix=s(i.BaseFilter,{type:"ColorMatrix",fragmentSource:"precision highp float;\nuniform sampler2D uTexture;\nvarying vec2 vTexCoord;\nuniform mat4 uColorMatrix;\nuniform vec4 uConstants;\nvoid main() {\nvec4 color = texture2D(uTexture, vTexCoord);\ncolor *= uColorMatrix;\ncolor += uConstants;\ngl_FragColor = color;\n}",matrix:[1,0,0,0,0,0,1,0,0,0,0,0,1,0,0,0,0,0,1,0],mainParameter:"matrix",colorsOnly:!0,initialize:function(e){this.callSuper("initialize",e),this.matrix=this.matrix.slice(0)},applyTo2d:function(e){var t,i,s,n,r,o=e.imageData.data,a=o.length,l=this.matrix,c=this.colorsOnly;for(r=0;r=b||o<0||o>=C||(l=4*(a*C+o),c=f[g*_+u],t+=m[l]*c,i+=m[l+1]*c,s+=m[l+2]*c,y||(n+=m[l+3]*c));S[r]=t,S[r+1]=i,S[r+2]=s,S[r+3]=y?m[r+3]:n}e.imageData=E},getUniformLocations:function(e,t){return{uMatrix:e.getUniformLocation(t,"uMatrix"),uOpaque:e.getUniformLocation(t,"uOpaque"),uHalfSize:e.getUniformLocation(t,"uHalfSize"),uSize:e.getUniformLocation(t,"uSize")}},sendUniformData:function(e,t){e.uniform1fv(t.uMatrix,this.matrix)},toObject:function(){return i(this.callSuper("toObject"),{opaque:this.opaque,matrix:this.matrix})}}),t.Image.filters.Convolute.fromObject=t.Image.filters.BaseFilter.fromObject}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.Image.filters,s=t.util.createClass;i.Grayscale=s(i.BaseFilter,{type:"Grayscale",fragmentSource:{average:"precision highp float;\nuniform sampler2D uTexture;\nvarying vec2 vTexCoord;\nvoid main() {\nvec4 color = texture2D(uTexture, vTexCoord);\nfloat average = (color.r + color.b + color.g) / 3.0;\ngl_FragColor = vec4(average, average, average, color.a);\n}",lightness:"precision highp float;\nuniform sampler2D uTexture;\nuniform int uMode;\nvarying vec2 vTexCoord;\nvoid main() {\nvec4 col = texture2D(uTexture, vTexCoord);\nfloat average = (max(max(col.r, col.g),col.b) + min(min(col.r, col.g),col.b)) / 2.0;\ngl_FragColor = vec4(average, average, average, col.a);\n}",luminosity:"precision highp float;\nuniform sampler2D uTexture;\nuniform int uMode;\nvarying vec2 vTexCoord;\nvoid main() {\nvec4 col = texture2D(uTexture, vTexCoord);\nfloat average = 0.21 * col.r + 0.72 * col.g + 0.07 * col.b;\ngl_FragColor = vec4(average, average, average, col.a);\n}"},mode:"average",mainParameter:"mode",applyTo2d:function(e){var t,i,s=e.imageData.data,n=s.length,r=this.mode;for(t=0;tc[0]&&n>c[1]&&r>c[2]&&s 0.0) {\n"+this.fragmentSource[e]+"}\n}"},retrieveShader:function(e){var t,i=this.type+"_"+this.mode;return e.programCache.hasOwnProperty(i)||(t=this.buildSource(this.mode),e.programCache[i]=this.createProgram(e.context,t)),e.programCache[i]},applyTo2d:function(e){var i,s,n,r,o,a,l,c=e.imageData.data,h=c.length,d=1-this.alpha;i=(l=new t.Color(this.color).getSource())[0]*this.alpha,s=l[1]*this.alpha,n=l[2]*this.alpha;for(var u=0;u=e||t<=-e)return 0;if(t<1.1920929e-7&&t>-1.1920929e-7)return 1;var i=(t*=Math.PI)/e;return a(t)/t*a(i)/i}},applyTo2d:function(e){var t=e.imageData,i=this.scaleX,s=this.scaleY;this.rcpScaleX=1/i,this.rcpScaleY=1/s;var n,r=t.width,a=t.height,l=o(r*i),c=o(a*s);"sliceHack"===this.resizeType?n=this.sliceByTwo(e,r,a,l,c):"hermite"===this.resizeType?n=this.hermiteFastResize(e,r,a,l,c):"bilinear"===this.resizeType?n=this.bilinearFiltering(e,r,a,l,c):"lanczos"===this.resizeType&&(n=this.lanczosResize(e,r,a,l,c)),e.imageData=n},sliceByTwo:function(e,i,n,r,o){var a,l,c=e.imageData,h=.5,d=!1,u=!1,g=i*h,p=n*h,m=t.filterBackend.resources,f=0,_=0,v=i,C=0;for(m.sliceByTwo||(m.sliceByTwo=document.createElement("canvas")),((a=m.sliceByTwo).width<1.5*i||a.height=t)){I=s(1e3*r(w-E.x)),b[I]||(b[I]={});for(var D=S.y-C;D<=S.y+C;D++)D<0||D>=o||(O=s(1e3*r(D-E.y)),b[I][O]||(b[I][O]=g(n(i(I*f,2)+i(O*_,2))/1e3)),(L=b[I][O])>0&&(T+=L,x+=L*h[R=4*(D*t+w)],k+=L*h[R+1],A+=L*h[R+2],N+=L*h[R+3]))}u[R=4*(y*a+l)]=x/T,u[R+1]=k/T,u[R+2]=A/T,u[R+3]=N/T}return++l1&&O<-1||(C=2*O*O*O-3*O*O+1)>0&&(L+=C*g[(I=4*(N+T*t))+3],E+=C,g[I+3]<255&&(C=C*g[I+3]/250),S+=C*g[I],y+=C*g[I+1],w+=C*g[I+2],b+=C)}m[v]=S/b,m[v+1]=y/b,m[v+2]=w/b,m[v+3]=L/E}return p},toObject:function(){return{type:this.type,scaleX:this.scaleX,scaleY:this.scaleY,resizeType:this.resizeType,lanczosLobes:this.lanczosLobes}}}),t.Image.filters.Resize.fromObject=t.Image.filters.BaseFilter.fromObject}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.Image.filters,s=t.util.createClass;i.Contrast=s(i.BaseFilter,{type:"Contrast",fragmentSource:"precision highp float;\nuniform sampler2D uTexture;\nuniform float uContrast;\nvarying vec2 vTexCoord;\nvoid main() {\nvec4 color = texture2D(uTexture, vTexCoord);\nfloat contrastF = 1.015 * (uContrast + 1.0) / (1.0 * (1.015 - uContrast));\ncolor.rgb = contrastF * (color.rgb - 0.5) + 0.5;\ngl_FragColor = color;\n}",contrast:0,mainParameter:"contrast",applyTo2d:function(e){if(0!==this.contrast){var t,i=e.imageData.data,s=i.length,n=Math.floor(255*this.contrast),r=259*(n+255)/(255*(259-n));for(t=0;t1&&(t=1/this.aspectRatio):this.aspectRatio<1&&(t=this.aspectRatio),e=t*this.blur*.12,this.horizontal?i[0]=e:i[1]=e,i}}),i.Blur.fromObject=t.Image.filters.BaseFilter.fromObject}(t),function(e){"use strict";var t=e.fabric||(e.fabric={}),i=t.Image.filters,s=t.util.createClass;i.Gamma=s(i.BaseFilter,{type:"Gamma",fragmentSource:"precision highp float;\nuniform sampler2D uTexture;\nuniform vec3 uGamma;\nvarying vec2 vTexCoord;\nvoid main() {\nvec4 color = texture2D(uTexture, vTexCoord);\nvec3 correction = (1.0 / uGamma);\ncolor.r = pow(color.r, correction.r);\ncolor.g = pow(color.g, correction.g);\ncolor.b = pow(color.b, correction.b);\ngl_FragColor = color;\ngl_FragColor.rgb *= color.a;\n}",gamma:[1,1,1],mainParameter:"gamma",initialize:function(e){this.gamma=[1,1,1],i.BaseFilter.prototype.initialize.call(this,e)},applyTo2d:function(e){var t,i=e.imageData.data,s=this.gamma,n=i.length,r=1/s[0],o=1/s[1],a=1/s[2];for(this.rVals||(this.rVals=new Uint8Array(256),this.gVals=new Uint8Array(256),this.bVals=new Uint8Array(256)),t=0,n=256;t'},_getCacheCanvasDimensions:function(){var e=this.callSuper("_getCacheCanvasDimensions"),t=this.fontSize;return e.width+=t*e.zoomX,e.height+=t*e.zoomY,e},_render:function(e){var t=this.path;t&&!t.isNotVisible()&&t._render(e),this._setTextStyles(e),this._renderTextLinesBackground(e),this._renderTextDecoration(e,"underline"),this._renderText(e),this._renderTextDecoration(e,"overline"),this._renderTextDecoration(e,"linethrough")},_renderText:function(e){"stroke"===this.paintFirst?(this._renderTextStroke(e),this._renderTextFill(e)):(this._renderTextFill(e),this._renderTextStroke(e))},_setTextStyles:function(e,t,i){if(e.textBaseline="alphabetical",this.path)switch(this.pathAlign){case"center":e.textBaseline="middle";break;case"ascender":e.textBaseline="top";break;case"descender":e.textBaseline="bottom"}e.font=this._getFontDeclaration(t,i)},calcTextWidth:function(){for(var e=this.getLineWidth(0),t=1,i=this._textLines.length;te&&(e=s)}return e},_renderTextLine:function(e,t,i,s,n,r){this._renderChars(e,t,i,s,n,r)},_renderTextLinesBackground:function(e){if(this.textBackgroundColor||this.styleHas("textBackgroundColor")){for(var t,i,s,n,r,o,a,l=e.fillStyle,c=this._getLeftOffset(),h=this._getTopOffset(),d=0,u=0,g=this.path,p=0,m=this._textLines.length;p=0:ia?d%=a:d<0&&(d+=a),this._setGraphemeOnPath(d,r,o),d+=r.kernedWidth}return{width:l,numOfSpaces:0}},_setGraphemeOnPath:function(e,i,s){var n=e+i.kernedWidth/2,r=this.path,o=t.util.getPointOnPath(r.path,n,r.segmentsInfo);i.renderLeft=o.x-s.x,i.renderTop=o.y-s.y,i.angle=o.angle+("right"===this.pathSide?Math.PI:0)},_getGraphemeBox:function(e,t,i,s,n){var r,o=this.getCompleteStyleDeclaration(t,i),a=s?this.getCompleteStyleDeclaration(t,i-1):{},l=this._measureChar(e,o,s,a),c=l.kernedWidth,h=l.width;0!==this.charSpacing&&(h+=r=this._getWidthOfCharSpacing(),c+=r);var d={width:h,left:0,height:o.fontSize,kernedWidth:c,deltaY:o.deltaY};if(i>0&&!n){var u=this.__charBounds[t][i-1];d.left=u.left+u.width+l.kernedWidth-l.width}return d},getHeightOfLine:function(e){if(this.__lineHeights[e])return this.__lineHeights[e];for(var t=this._textLines[e],i=this.getHeightOfChar(e,0),s=1,n=t.length;s0){var T=v+r+d;"rtl"===this.direction&&(T=this.width-T-u),c&&_&&(e.fillStyle=_,e.fillRect(T,h+S*s+o,u,this.fontSize/15)),d=g.left,u=g.width,c=p,_=f,s=n,o=a}else u+=g.kernedWidth;T=v+r+d;"rtl"===this.direction&&(T=this.width-T-u),e.fillStyle=f,p&&f&&e.fillRect(T,h+S*s+o,u-E,this.fontSize/15),C+=i}else C+=i;e.restore()}},_getFontDeclaration:function(e,i){var s=e||this,n=this.fontFamily,r=t.Text.genericFonts.indexOf(n.toLowerCase())>-1,o=void 0===n||n.indexOf("'")>-1||n.indexOf(",")>-1||n.indexOf('"')>-1||r?s.fontFamily:'"'+s.fontFamily+'"';return[t.isLikelyNode?s.fontWeight:s.fontStyle,t.isLikelyNode?s.fontStyle:s.fontWeight,i?this.CACHE_FONT_SIZE+"px":s.fontSize+"px",o].join(" ")},render:function(e){this.visible&&(this.canvas&&this.canvas.skipOffscreen&&!this.group&&!this.isOnScreen()||(this._shouldClearDimensionCache()&&this.initDimensions(),this.callSuper("render",e)))},_splitTextIntoLines:function(e){for(var i=e.split(this._reNewline),s=new Array(i.length),n=["\n"],r=[],o=0;o-1&&(e.underline=!0),e.textDecoration.indexOf("line-through")>-1&&(e.linethrough=!0),e.textDecoration.indexOf("overline")>-1&&(e.overline=!0),delete e.textDecoration)}n.IText=n.util.createClass(n.Text,n.Observable,{type:"i-text",selectionStart:0,selectionEnd:0,selectionColor:"rgba(17,119,255,0.3)",isEditing:!1,editable:!0,editingBorderColor:"rgba(102,153,255,0.25)",cursorWidth:2,cursorColor:"",cursorDelay:1e3,cursorDuration:600,caching:!0,hiddenTextareaContainer:null,_reSpace:/\s|\n/,_currentCursorOpacity:0,_selectionDirection:null,_abortCursorAnimation:!1,__widthOfSpace:[],inCompositionMode:!1,initialize:function(e,t){this.callSuper("initialize",e,t),this.initBehavior()},setSelectionStart:function(e){e=Math.max(e,0),this._updateAndFire("selectionStart",e)},setSelectionEnd:function(e){e=Math.min(e,this.text.length),this._updateAndFire("selectionEnd",e)},_updateAndFire:function(e,t){this[e]!==t&&(this._fireSelectionChanged(),this[e]=t),this._updateTextarea()},_fireSelectionChanged:function(){this.fire("selection:changed"),this.canvas&&this.canvas.fire("text:selection:changed",{target:this})},initDimensions:function(){this.isEditing&&this.initDelayedCursor(),this.clearContextTop(),this.callSuper("initDimensions")},render:function(e){this.clearContextTop(),this.callSuper("render",e),this.cursorOffsetCache={},this.renderCursorOrSelection()},_render:function(e){this.callSuper("_render",e)},clearContextTop:function(e){if(this.isEditing&&this.canvas&&this.canvas.contextTop){var t=this.canvas.contextTop,i=this.canvas.viewportTransform;t.save(),t.transform(i[0],i[1],i[2],i[3],i[4],i[5]),this.transform(t),this._clearTextArea(t),e||t.restore()}},renderCursorOrSelection:function(){if(this.isEditing&&this.canvas&&this.canvas.contextTop){var e=this._getCursorBoundaries(),t=this.canvas.contextTop;this.clearContextTop(!0),this.selectionStart===this.selectionEnd?this.renderCursor(e,t):this.renderSelection(e,t),t.restore()}},_clearTextArea:function(e){var t=this.width+4,i=this.height+4;e.clearRect(-t/2,-i/2,t,i)},_getCursorBoundaries:function(e){"undefined"===typeof e&&(e=this.selectionStart);var t=this._getLeftOffset(),i=this._getTopOffset(),s=this._getCursorBoundariesOffsets(e);return{left:t,top:i,leftOffset:s.left,topOffset:s.top}},_getCursorBoundariesOffsets:function(e){if(this.cursorOffsetCache&&"top"in this.cursorOffsetCache)return this.cursorOffsetCache;var t,i,s,n,r=0,o=0,a=this.get2DCursorLocation(e);s=a.charIndex,i=a.lineIndex;for(var l=0;l0?o:0)},"rtl"===this.direction&&(n.left*=-1),this.cursorOffsetCache=n,this.cursorOffsetCache},renderCursor:function(e,t){var i=this.get2DCursorLocation(),s=i.lineIndex,n=i.charIndex>0?i.charIndex-1:0,r=this.getValueOfPropertyAt(s,n,"fontSize"),o=this.scaleX*this.canvas.getZoom(),a=this.cursorWidth/o,l=e.topOffset,c=this.getValueOfPropertyAt(s,n,"deltaY");l+=(1-this._fontSizeFraction)*this.getHeightOfLine(s)/this.lineHeight-r*(1-this._fontSizeFraction),this.inCompositionMode&&this.renderSelection(e,t),t.fillStyle=this.cursorColor||this.getValueOfPropertyAt(s,n,"fill"),t.globalAlpha=this.__isMousedown?1:this._currentCursorOpacity,t.fillRect(e.left+e.leftOffset-a/2,l+e.top+c,a,r)},renderSelection:function(e,t){for(var i=this.inCompositionMode?this.hiddenTextarea.selectionStart:this.selectionStart,s=this.inCompositionMode?this.hiddenTextarea.selectionEnd:this.selectionEnd,n=-1!==this.textAlign.indexOf("justify"),r=this.get2DCursorLocation(i),o=this.get2DCursorLocation(s),a=r.lineIndex,l=o.lineIndex,c=r.charIndex<0?0:r.charIndex,h=o.charIndex<0?0:o.charIndex,d=a;d<=l;d++){var u,g=this._getLineLeftOffset(d)||0,p=this.getHeightOfLine(d),m=0,f=0;if(d===a&&(m=this.__charBounds[a][c].left),d>=a&&d1)&&(p/=this.lineHeight);var v=e.left+g+m,C=f-m,b=p,E=0;this.inCompositionMode?(t.fillStyle=this.compositionColor||"black",b=1,E=p):t.fillStyle=this.selectionColor,"rtl"===this.direction&&(v=this.width-v-C),t.fillRect(v,e.top+e.topOffset+E,C,b),e.topOffset+=u}},getCurrentCharFontSize:function(){var e=this._getCurrentCharIndex();return this.getValueOfPropertyAt(e.l,e.c,"fontSize")},getCurrentCharColor:function(){var e=this._getCurrentCharIndex();return this.getValueOfPropertyAt(e.l,e.c,"fill")},_getCurrentCharIndex:function(){var e=this.get2DCursorLocation(this.selectionStart,!0),t=e.charIndex>0?e.charIndex-1:0;return{l:e.lineIndex,c:t}}}),n.IText.fromObject=function(t,i){var s=n.util.stylesFromArray(t.styles,t.text),r=Object.assign({},t,{styles:s});if(delete r.path,e(r),r.styles)for(var o in r.styles)for(var a in r.styles[o])e(r.styles[o][a]);n.Object._fromObject("IText",r,(function(e){t.path?n.Object._fromObject("Path",t.path,(function(t){e.set("path",t),i(e)}),"path"):i(e)}),"text")}}(),function(){var e=n.util.object.clone;n.util.object.extend(n.IText.prototype,{initBehavior:function(){this.initAddedHandler(),this.initRemovedHandler(),this.initCursorSelectionHandlers(),this.initDoubleClickSimulation(),this.mouseMoveHandler=this.mouseMoveHandler.bind(this)},onDeselect:function(){this.isEditing&&this.exitEditing(),this.selected=!1},initAddedHandler:function(){var e=this;this.on("added",(function(){var t=e.canvas;t&&(t._hasITextHandlers||(t._hasITextHandlers=!0,e._initCanvasHandlers(t)),t._iTextInstances=t._iTextInstances||[],t._iTextInstances.push(e))}))},initRemovedHandler:function(){var e=this;this.on("removed",(function(){var t=e.canvas;t&&(t._iTextInstances=t._iTextInstances||[],n.util.removeFromArray(t._iTextInstances,e),0===t._iTextInstances.length&&(t._hasITextHandlers=!1,e._removeCanvasHandlers(t)))}))},_initCanvasHandlers:function(e){e._mouseUpITextHandler=function(){e._iTextInstances&&e._iTextInstances.forEach((function(e){e.__isMousedown=!1}))},e.on("mouse:up",e._mouseUpITextHandler)},_removeCanvasHandlers:function(e){e.off("mouse:up",e._mouseUpITextHandler)},_tick:function(){this._currentTickState=this._animateCursor(this,1,this.cursorDuration,"_onTickComplete")},_animateCursor:function(e,t,i,s){var n;return n={isAborted:!1,abort:function(){this.isAborted=!0}},e.animate("_currentCursorOpacity",t,{duration:i,onComplete:function(){n.isAborted||e[s]()},onChange:function(){e.canvas&&e.selectionStart===e.selectionEnd&&e.renderCursorOrSelection()},abort:function(){return n.isAborted}}),n},_onTickComplete:function(){var e=this;this._cursorTimeout1&&clearTimeout(this._cursorTimeout1),this._cursorTimeout1=setTimeout((function(){e._currentTickCompleteState=e._animateCursor(e,0,this.cursorDuration/2,"_tick")}),100)},initDelayedCursor:function(e){var t=this,i=e?0:this.cursorDelay;this.abortCursorAnimation(),this._currentCursorOpacity=1,this._cursorTimeout2=setTimeout((function(){t._tick()}),i)},abortCursorAnimation:function(){var e=this._currentTickState||this._currentTickCompleteState,t=this.canvas;this._currentTickState&&this._currentTickState.abort(),this._currentTickCompleteState&&this._currentTickCompleteState.abort(),clearTimeout(this._cursorTimeout1),clearTimeout(this._cursorTimeout2),this._currentCursorOpacity=0,e&&t&&t.clearContext(t.contextTop||t.contextContainer)},selectAll:function(){return this.selectionStart=0,this.selectionEnd=this._text.length,this._fireSelectionChanged(),this._updateTextarea(),this},getSelectedText:function(){return this._text.slice(this.selectionStart,this.selectionEnd).join("")},findWordBoundaryLeft:function(e){var t=0,i=e-1;if(this._reSpace.test(this._text[i]))for(;this._reSpace.test(this._text[i]);)t++,i--;for(;/\S/.test(this._text[i])&&i>-1;)t++,i--;return e-t},findWordBoundaryRight:function(e){var t=0,i=e;if(this._reSpace.test(this._text[i]))for(;this._reSpace.test(this._text[i]);)t++,i++;for(;/\S/.test(this._text[i])&&i-1;)t++,i--;return e-t},findLineBoundaryRight:function(e){for(var t=0,i=e;!/\n/.test(this._text[i])&&i0&&sthis.__selectionStartOnMouseDown?(this.selectionStart=this.__selectionStartOnMouseDown,this.selectionEnd=t):(this.selectionStart=t,this.selectionEnd=this.__selectionStartOnMouseDown),this.selectionStart===i&&this.selectionEnd===s||(this.restartCursorIfNeeded(),this._fireSelectionChanged(),this._updateTextarea(),this.renderCursorOrSelection()))}},_setEditingProps:function(){this.hoverCursor="text",this.canvas&&(this.canvas.defaultCursor=this.canvas.moveCursor="text"),this.borderColor=this.editingBorderColor,this.hasControls=this.selectable=!1,this.lockMovementX=this.lockMovementY=!0},fromStringToGraphemeSelection:function(e,t,i){var s=i.slice(0,e),r=n.util.string.graphemeSplit(s).length;if(e===t)return{selectionStart:r,selectionEnd:r};var o=i.slice(e,t);return{selectionStart:r,selectionEnd:r+n.util.string.graphemeSplit(o).length}},fromGraphemeToStringSelection:function(e,t,i){var s=i.slice(0,e).join("").length;return e===t?{selectionStart:s,selectionEnd:s}:{selectionStart:s,selectionEnd:s+i.slice(e,t).join("").length}},_updateTextarea:function(){if(this.cursorOffsetCache={},this.hiddenTextarea){if(!this.inCompositionMode){var e=this.fromGraphemeToStringSelection(this.selectionStart,this.selectionEnd,this._text);this.hiddenTextarea.selectionStart=e.selectionStart,this.hiddenTextarea.selectionEnd=e.selectionEnd}this.updateTextareaPosition()}},updateFromTextArea:function(){if(this.hiddenTextarea){this.cursorOffsetCache={},this.text=this.hiddenTextarea.value,this._shouldClearDimensionCache()&&(this.initDimensions(),this.setCoords());var e=this.fromStringToGraphemeSelection(this.hiddenTextarea.selectionStart,this.hiddenTextarea.selectionEnd,this.hiddenTextarea.value);this.selectionEnd=this.selectionStart=e.selectionEnd,this.inCompositionMode||(this.selectionStart=e.selectionStart),this.updateTextareaPosition()}},updateTextareaPosition:function(){if(this.selectionStart===this.selectionEnd){var e=this._calcTextareaPosition();this.hiddenTextarea.style.left=e.left,this.hiddenTextarea.style.top=e.top}},_calcTextareaPosition:function(){if(!this.canvas)return{x:1,y:1};var e=this.inCompositionMode?this.compositionStart:this.selectionStart,t=this._getCursorBoundaries(e),i=this.get2DCursorLocation(e),s=i.lineIndex,r=i.charIndex,o=this.getValueOfPropertyAt(s,r,"fontSize")*this.lineHeight,a=t.leftOffset,l=this.calcTransformMatrix(),c={x:t.left+a,y:t.top+t.topOffset+o},h=this.canvas.getRetinaScaling(),d=this.canvas.upperCanvasEl,u=d.width/h,g=d.height/h,p=u-o,m=g-o,f=d.clientWidth/u,_=d.clientHeight/g;return c=n.util.transformPoint(c,l),(c=n.util.transformPoint(c,this.canvas.viewportTransform)).x*=f,c.y*=_,c.x<0&&(c.x=0),c.x>p&&(c.x=p),c.y<0&&(c.y=0),c.y>m&&(c.y=m),c.x+=this.canvas._offset.left,c.y+=this.canvas._offset.top,{left:c.x+"px",top:c.y+"px",fontSize:o+"px",charHeight:o}},_saveEditingProps:function(){this._savedProps={hasControls:this.hasControls,borderColor:this.borderColor,lockMovementX:this.lockMovementX,lockMovementY:this.lockMovementY,hoverCursor:this.hoverCursor,selectable:this.selectable,defaultCursor:this.canvas&&this.canvas.defaultCursor,moveCursor:this.canvas&&this.canvas.moveCursor}},_restoreEditingProps:function(){this._savedProps&&(this.hoverCursor=this._savedProps.hoverCursor,this.hasControls=this._savedProps.hasControls,this.borderColor=this._savedProps.borderColor,this.selectable=this._savedProps.selectable,this.lockMovementX=this._savedProps.lockMovementX,this.lockMovementY=this._savedProps.lockMovementY,this.canvas&&(this.canvas.defaultCursor=this._savedProps.defaultCursor,this.canvas.moveCursor=this._savedProps.moveCursor))},exitEditing:function(){var e=this._textBeforeEdit!==this.text,t=this.hiddenTextarea;return this.selected=!1,this.isEditing=!1,this.selectionEnd=this.selectionStart,t&&(t.blur&&t.blur(),t.parentNode&&t.parentNode.removeChild(t)),this.hiddenTextarea=null,this.abortCursorAnimation(),this._restoreEditingProps(),this._currentCursorOpacity=0,this._shouldClearDimensionCache()&&(this.initDimensions(),this.setCoords()),this.fire("editing:exited"),e&&this.fire("modified"),this.canvas&&(this.canvas.off("mouse:move",this.mouseMoveHandler),this.canvas.fire("text:editing:exited",{target:this}),e&&this.canvas.fire("object:modified",{target:this})),this},_removeExtraneousStyles:function(){for(var e in this.styles)this._textLines[e]||delete this.styles[e]},removeStyleFromTo:function(e,t){var i,s,n=this.get2DCursorLocation(e,!0),r=this.get2DCursorLocation(t,!0),o=n.lineIndex,a=n.charIndex,l=r.lineIndex,c=r.charIndex;if(o!==l){if(this.styles[o])for(i=a;i=c&&(s[h-u]=s[d],delete s[d])}},shiftLineStyles:function(t,i){var s=e(this.styles);for(var n in this.styles){var r=parseInt(n,10);r>t&&(this.styles[r+i]=s[r],s[r-i]||delete this.styles[r])}},restartCursorIfNeeded:function(){this._currentTickState&&!this._currentTickState.isAborted&&this._currentTickCompleteState&&!this._currentTickCompleteState.isAborted||this.initDelayedCursor()},insertNewlineStyleObject:function(t,i,s,n){var r,o={},a=!1,l=this._unwrappedTextLines[t].length,c=l===i;for(var h in s||(s=1),this.shiftLineStyles(t,s),this.styles[t]&&(r=this.styles[t][0===i?i:i-1]),this.styles[t]){var d=parseInt(h,10);d>=i&&(a=!0,o[d-i]=this.styles[t][h],c&&0===i||delete this.styles[t][h])}var u=!1;for(a&&!c&&(this.styles[t+s]=o,u=!0),(u||l>i)&&s--;s>0;)n&&n[s-1]?this.styles[t+s]={0:e(n[s-1])}:r?this.styles[t+s]={0:e(r)}:delete this.styles[t+s],s--;this._forceClearCache=!0},insertCharStyleObject:function(t,i,s,n){this.styles||(this.styles={});var r=this.styles[t],o=r?e(r):{};for(var a in s||(s=1),o){var l=parseInt(a,10);l>=i&&(r[l+s]=o[l],o[l-s]||delete r[l])}if(this._forceClearCache=!0,n)for(;s--;)Object.keys(n[s]).length&&(this.styles[t]||(this.styles[t]={}),this.styles[t][i+s]=e(n[s]));else if(r)for(var c=r[i?i-1:1];c&&s--;)this.styles[t][i+s]=e(c)},insertNewStyleBlock:function(e,t,i){for(var s=this.get2DCursorLocation(t,!0),n=[0],r=0,o=0;o0&&(this.insertCharStyleObject(s.lineIndex,s.charIndex,n[0],i),i=i&&i.slice(n[0]+1)),r&&this.insertNewlineStyleObject(s.lineIndex,s.charIndex+n[0],r);for(o=1;o0?this.insertCharStyleObject(s.lineIndex+o,0,n[o],i):i&&this.styles[s.lineIndex+o]&&i[0]&&(this.styles[s.lineIndex+o][0]=i[0]),i=i&&i.slice(n[o]+1);n[o]>0&&this.insertCharStyleObject(s.lineIndex+o,0,n[o],i)},setSelectionStartEndWithShift:function(e,t,i){i<=e?(t===e?this._selectionDirection="left":"right"===this._selectionDirection&&(this._selectionDirection="left",this.selectionEnd=e),this.selectionStart=i):i>e&&ie?this.selectionStart=e:this.selectionStart<0&&(this.selectionStart=0),this.selectionEnd>e?this.selectionEnd=e:this.selectionEnd<0&&(this.selectionEnd=0)}})}(),n.util.object.extend(n.IText.prototype,{initDoubleClickSimulation:function(){this.__lastClickTime=+new Date,this.__lastLastClickTime=+new Date,this.__lastPointer={},this.on("mousedown",this.onMouseDown)},onMouseDown:function(e){if(this.canvas){this.__newClickTime=+new Date;var t=e.pointer;this.isTripleClick(t)&&(this.fire("tripleclick",e),this._stopEvent(e.e)),this.__lastLastClickTime=this.__lastClickTime,this.__lastClickTime=this.__newClickTime,this.__lastPointer=t,this.__lastIsEditing=this.isEditing,this.__lastSelected=this.selected}},isTripleClick:function(e){return this.__newClickTime-this.__lastClickTime<500&&this.__lastClickTime-this.__lastLastClickTime<500&&this.__lastPointer.x===e.x&&this.__lastPointer.y===e.y},_stopEvent:function(e){e.preventDefault&&e.preventDefault(),e.stopPropagation&&e.stopPropagation()},initCursorSelectionHandlers:function(){this.initMousedownHandler(),this.initMouseupHandler(),this.initClicks()},doubleClickHandler:function(e){this.isEditing&&this.selectWord(this.getSelectionStartFromPointer(e.e))},tripleClickHandler:function(e){this.isEditing&&this.selectLine(this.getSelectionStartFromPointer(e.e))},initClicks:function(){this.on("mousedblclick",this.doubleClickHandler),this.on("tripleclick",this.tripleClickHandler)},_mouseDownHandler:function(e){!this.canvas||!this.editable||e.e.button&&1!==e.e.button||(this.__isMousedown=!0,this.selected&&(this.inCompositionMode=!1,this.setCursorByClick(e.e)),this.isEditing&&(this.__selectionStartOnMouseDown=this.selectionStart,this.selectionStart===this.selectionEnd&&this.abortCursorAnimation(),this.renderCursorOrSelection()))},_mouseDownHandlerBefore:function(e){!this.canvas||!this.editable||e.e.button&&1!==e.e.button||(this.selected=this===this.canvas._activeObject)},initMousedownHandler:function(){this.on("mousedown",this._mouseDownHandler),this.on("mousedown:before",this._mouseDownHandlerBefore)},initMouseupHandler:function(){this.on("mouseup",this.mouseUpHandler)},mouseUpHandler:function(e){if(this.__isMousedown=!1,!(!this.editable||this.group||e.transform&&e.transform.actionPerformed||e.e.button&&1!==e.e.button)){if(this.canvas){var t=this.canvas._activeObject;if(t&&t!==this)return}this.__lastSelected&&!this.__corner?(this.selected=!1,this.__lastSelected=!1,this.enterEditing(e.e),this.selectionStart===this.selectionEnd?this.initDelayedCursor(!0):this.renderCursorOrSelection()):this.selected=!0}},setCursorByClick:function(e){var t=this.getSelectionStartFromPointer(e),i=this.selectionStart,s=this.selectionEnd;e.shiftKey?this.setSelectionStartEndWithShift(i,s,t):(this.selectionStart=t,this.selectionEnd=t),this.isEditing&&(this._fireSelectionChanged(),this._updateTextarea())},getSelectionStartFromPointer:function(e){for(var t,i=this.getLocalPointer(e),s=0,n=0,r=0,o=0,a=0,l=0,c=this._textLines.length;l0&&(o+=this._textLines[l-1].length+this.missingNewlineOffset(l-1));n=this._getLineLeftOffset(a)*this.scaleX,t=this._textLines[a],"rtl"===this.direction&&(i.x=this.width*this.scaleX-i.x+n);for(var h=0,d=t.length;hr||o<0?0:1);return this.flipX&&(a=n-a),a>this._text.length&&(a=this._text.length),a}}),n.util.object.extend(n.IText.prototype,{initHiddenTextarea:function(){this.hiddenTextarea=n.document.createElement("textarea"),this.hiddenTextarea.setAttribute("autocapitalize","off"),this.hiddenTextarea.setAttribute("autocorrect","off"),this.hiddenTextarea.setAttribute("autocomplete","off"),this.hiddenTextarea.setAttribute("spellcheck","false"),this.hiddenTextarea.setAttribute("data-fabric-hiddentextarea",""),this.hiddenTextarea.setAttribute("wrap","off");var e=this._calcTextareaPosition();this.hiddenTextarea.style.cssText="position: absolute; top: "+e.top+"; left: "+e.left+"; z-index: -999; opacity: 0; width: 1px; height: 1px; font-size: 1px; padding-top: "+e.fontSize+";",this.hiddenTextareaContainer?this.hiddenTextareaContainer.appendChild(this.hiddenTextarea):n.document.body.appendChild(this.hiddenTextarea),n.util.addListener(this.hiddenTextarea,"keydown",this.onKeyDown.bind(this)),n.util.addListener(this.hiddenTextarea,"keyup",this.onKeyUp.bind(this)),n.util.addListener(this.hiddenTextarea,"input",this.onInput.bind(this)),n.util.addListener(this.hiddenTextarea,"copy",this.copy.bind(this)),n.util.addListener(this.hiddenTextarea,"cut",this.copy.bind(this)),n.util.addListener(this.hiddenTextarea,"paste",this.paste.bind(this)),n.util.addListener(this.hiddenTextarea,"compositionstart",this.onCompositionStart.bind(this)),n.util.addListener(this.hiddenTextarea,"compositionupdate",this.onCompositionUpdate.bind(this)),n.util.addListener(this.hiddenTextarea,"compositionend",this.onCompositionEnd.bind(this)),!this._clickHandlerInitialized&&this.canvas&&(n.util.addListener(this.canvas.upperCanvasEl,"click",this.onClick.bind(this)),this._clickHandlerInitialized=!0)},keysMap:{9:"exitEditing",27:"exitEditing",33:"moveCursorUp",34:"moveCursorDown",35:"moveCursorRight",36:"moveCursorLeft",37:"moveCursorLeft",38:"moveCursorUp",39:"moveCursorRight",40:"moveCursorDown"},keysMapRtl:{9:"exitEditing",27:"exitEditing",33:"moveCursorUp",34:"moveCursorDown",35:"moveCursorLeft",36:"moveCursorRight",37:"moveCursorRight",38:"moveCursorUp",39:"moveCursorLeft",40:"moveCursorDown"},ctrlKeysMapUp:{67:"copy",88:"cut"},ctrlKeysMapDown:{65:"selectAll"},onClick:function(){this.hiddenTextarea&&this.hiddenTextarea.focus()},onKeyDown:function(e){if(this.isEditing){var t="rtl"===this.direction?this.keysMapRtl:this.keysMap;if(e.keyCode in t)this[t[e.keyCode]](e);else{if(!(e.keyCode in this.ctrlKeysMapDown)||!e.ctrlKey&&!e.metaKey)return;this[this.ctrlKeysMapDown[e.keyCode]](e)}e.stopImmediatePropagation(),e.preventDefault(),e.keyCode>=33&&e.keyCode<=40?(this.inCompositionMode=!1,this.clearContextTop(),this.renderCursorOrSelection()):this.canvas&&this.canvas.requestRenderAll()}},onKeyUp:function(e){!this.isEditing||this._copyDone||this.inCompositionMode?this._copyDone=!1:e.keyCode in this.ctrlKeysMapUp&&(e.ctrlKey||e.metaKey)&&(this[this.ctrlKeysMapUp[e.keyCode]](e),e.stopImmediatePropagation(),e.preventDefault(),this.canvas&&this.canvas.requestRenderAll())},onInput:function(e){var t=this.fromPaste;if(this.fromPaste=!1,e&&e.stopPropagation(),this.isEditing){var i,s,r,o,a,l=this._splitTextIntoLines(this.hiddenTextarea.value).graphemeText,c=this._text.length,h=l.length,d=h-c,u=this.selectionStart,g=this.selectionEnd,p=u!==g;if(""===this.hiddenTextarea.value)return this.styles={},this.updateFromTextArea(),this.fire("changed"),void(this.canvas&&(this.canvas.fire("text:changed",{target:this}),this.canvas.requestRenderAll()));var m=this.fromStringToGraphemeSelection(this.hiddenTextarea.selectionStart,this.hiddenTextarea.selectionEnd,this.hiddenTextarea.value),f=u>m.selectionStart;p?(i=this._text.slice(u,g),d+=g-u):h0&&(s+=(i=this.__charBounds[e][t-1]).left+i.width),s},getDownCursorOffset:function(e,t){var i=this._getSelectionForOffset(e,t),s=this.get2DCursorLocation(i),n=s.lineIndex;if(n===this._textLines.length-1||e.metaKey||34===e.keyCode)return this._text.length-i;var r=s.charIndex,o=this._getWidthBeforeCursor(n,r),a=this._getIndexOnLine(n+1,o);return this._textLines[n].slice(r).length+a+1+this.missingNewlineOffset(n)},_getSelectionForOffset:function(e,t){return e.shiftKey&&this.selectionStart!==this.selectionEnd&&t?this.selectionEnd:this.selectionStart},getUpCursorOffset:function(e,t){var i=this._getSelectionForOffset(e,t),s=this.get2DCursorLocation(i),n=s.lineIndex;if(0===n||e.metaKey||33===e.keyCode)return-i;var r=s.charIndex,o=this._getWidthBeforeCursor(n,r),a=this._getIndexOnLine(n-1,o),l=this._textLines[n].slice(0,r),c=this.missingNewlineOffset(n-1);return-this._textLines[n-1].length+a-l.length+(1-c)},_getIndexOnLine:function(e,t){for(var i,s,n=this._textLines[e],r=this._getLineLeftOffset(e),o=0,a=0,l=n.length;at){s=!0;var c=r-i,h=r,d=Math.abs(c-t);o=Math.abs(h-t)=this._text.length&&this.selectionEnd>=this._text.length||this._moveCursorUpOrDown("Down",e)},moveCursorUp:function(e){0===this.selectionStart&&0===this.selectionEnd||this._moveCursorUpOrDown("Up",e)},_moveCursorUpOrDown:function(e,t){var i=this["get"+e+"CursorOffset"](t,"right"===this._selectionDirection);t.shiftKey?this.moveCursorWithShift(i):this.moveCursorWithoutShift(i),0!==i&&(this.setSelectionInBoundaries(),this.abortCursorAnimation(),this._currentCursorOpacity=1,this.initDelayedCursor(),this._fireSelectionChanged(),this._updateTextarea())},moveCursorWithShift:function(e){var t="left"===this._selectionDirection?this.selectionStart+e:this.selectionEnd+e;return this.setSelectionStartEndWithShift(this.selectionStart,this.selectionEnd,t),0!==e},moveCursorWithoutShift:function(e){return e<0?(this.selectionStart+=e,this.selectionEnd=this.selectionStart):(this.selectionEnd+=e,this.selectionStart=this.selectionEnd),0!==e},moveCursorLeft:function(e){0===this.selectionStart&&0===this.selectionEnd||this._moveCursorLeftOrRight("Left",e)},_move:function(e,t,i){var s;if(e.altKey)s=this["findWordBoundary"+i](this[t]);else{if(!e.metaKey&&35!==e.keyCode&&36!==e.keyCode)return this[t]+="Left"===i?-1:1,!0;s=this["findLineBoundary"+i](this[t])}if("undefined"!==typeof s&&this[t]!==s)return this[t]=s,!0},_moveLeft:function(e,t){return this._move(e,t,"Left")},_moveRight:function(e,t){return this._move(e,t,"Right")},moveCursorLeftWithoutShift:function(e){var t=!0;return this._selectionDirection="left",this.selectionEnd===this.selectionStart&&0!==this.selectionStart&&(t=this._moveLeft(e,"selectionStart")),this.selectionEnd=this.selectionStart,t},moveCursorLeftWithShift:function(e){return"right"===this._selectionDirection&&this.selectionStart!==this.selectionEnd?this._moveLeft(e,"selectionEnd"):0!==this.selectionStart?(this._selectionDirection="left",this._moveLeft(e,"selectionStart")):void 0},moveCursorRight:function(e){this.selectionStart>=this._text.length&&this.selectionEnd>=this._text.length||this._moveCursorLeftOrRight("Right",e)},_moveCursorLeftOrRight:function(e,t){var i="moveCursor"+e+"With";this._currentCursorOpacity=1,t.shiftKey?i+="Shift":i+="outShift",this[i](t)&&(this.abortCursorAnimation(),this.initDelayedCursor(),this._fireSelectionChanged(),this._updateTextarea())},moveCursorRightWithShift:function(e){return"left"===this._selectionDirection&&this.selectionStart!==this.selectionEnd?this._moveRight(e,"selectionStart"):this.selectionEnd!==this._text.length?(this._selectionDirection="right",this._moveRight(e,"selectionEnd")):void 0},moveCursorRightWithoutShift:function(e){var t=!0;return this._selectionDirection="right",this.selectionStart===this.selectionEnd?(t=this._moveRight(e,"selectionStart"),this.selectionEnd=this.selectionStart):this.selectionStart=this.selectionEnd,t},removeChars:function(e,t){"undefined"===typeof t&&(t=e+1),this.removeStyleFromTo(e,t),this._text.splice(e,t-e),this.text=this._text.join(""),this.set("dirty",!0),this._shouldClearDimensionCache()&&(this.initDimensions(),this.setCoords()),this._removeExtraneousStyles()},insertChars:function(e,t,i,s){"undefined"===typeof s&&(s=i),s>i&&this.removeStyleFromTo(i,s);var r=n.util.string.graphemeSplit(e);this.insertNewStyleBlock(r,i,t),this._text=[].concat(this._text.slice(0,i),r,this._text.slice(s)),this.text=this._text.join(""),this.set("dirty",!0),this._shouldClearDimensionCache()&&(this.initDimensions(),this.setCoords()),this._removeExtraneousStyles()}}),function(){var e=n.util.toFixed,t=n.util.radiansToDegrees,i=n.util.calcRotateMatrix,s=n.util.transformPoint,r=/ +/g;n.util.object.extend(n.Text.prototype,{_toSVG:function(){var e=this._getSVGLeftTopOffsets(),t=this._getSVGTextAndBg(e.textTop,e.textLeft);return this._wrapSVGTextAndBg(t)},toSVG:function(e){var t=this._createBaseSVGMarkup(this._toSVG(),{reviver:e,noStyle:!0,withShadow:!0}),i=this.path;return i?t+i._createBaseSVGMarkup(i._toSVG(),{reviver:e,withShadow:!0}):t},_getSVGLeftTopOffsets:function(){return{textLeft:-this.width/2,textTop:-this.height/2,lineTop:this.getHeightOfLine(0)}},_wrapSVGTextAndBg:function(e){var t=this.getSvgTextDecoration(this);return[e.textBgRects.join(""),'\t\t",e.textSpans.join(""),"\n"]},_getSVGTextAndBg:function(e,t){var i,s=[],n=[],r=e;this._setSVGBg(n);for(var o=0,a=this._textLines.length;o",n.util.string.escapeXml(o),""].join("")},_setSVGTextLineText:function(e,t,i,s){var r,o,a,l,c,h=this.getHeightOfLine(t),d=-1!==this.textAlign.indexOf("justify"),u="",g=0,p=this._textLines[t];s+=h*(1-this._fontSizeFraction)/this.lineHeight;for(var m=0,f=p.length-1;m<=f;m++)c=m===f||this.charSpacing||this.path,u+=p[m],a=this.__charBounds[t][m],0===g?(i+=a.kernedWidth-a.width,g+=a.width):g+=a.kernedWidth,d&&!c&&this._reSpaceAndTab.test(p[m])&&(c=!0),c||(r=r||this.getCompleteStyleDeclaration(t,m),o=this.getCompleteStyleDeclaration(t,m+1),c=n.util.hasStyleChanged(r,o,!0)),c&&(l=this._getStyleDeclaration(t,m)||{},e.push(this._createTextCharSpan(u,l,i,s,a)),u="",r=o,i+=g,g=0)},_pushTextBgRect:function(t,i,s,r,o,a){var l=n.Object.NUM_FRACTION_DIGITS;t.push("\t\t\n')},_setSVGTextLineBg:function(e,t,i,s){for(var n,r,o=this._textLines[t],a=this.getHeightOfLine(t)/this.lineHeight,l=0,c=0,h=this.getValueOfPropertyAt(t,0,"textBackgroundColor"),d=0,u=o.length;dthis.width&&this._set("width",this.dynamicMinWidth),-1!==this.textAlign.indexOf("justify")&&this.enlargeSpaces(),this.height=this.calcTextHeight(),this.saveState({propertySet:"_dimensionAffectingProps"}))},_generateStyleMap:function(e){for(var t=0,i=0,s=0,n={},r=0;r0?(i=0,s++,t++):!this.splitByGrapheme&&this._reSpaceAndTab.test(e.graphemeText[s])&&r>0&&(i++,s++),n[r]={line:t,offset:i},s+=e.graphemeLines[r].length,i+=e.graphemeLines[r].length;return n},styleHas:function(e,i){if(this._styleMap&&!this.isWrapping){var s=this._styleMap[i];s&&(i=s.line)}return t.Text.prototype.styleHas.call(this,e,i)},isEmptyStyles:function(e){if(!this.styles)return!0;var t,i,s=0,n=!1,r=this._styleMap[e],o=this._styleMap[e+1];for(var a in r&&(e=r.line,s=r.offset),o&&(n=o.line===e,t=o.offset),i="undefined"===typeof e?this.styles:{line:this.styles[e]})for(var l in i[a])if(l>=s&&(!n||ls&&!f?(a.push(l),l=[],r=g,f=!0):r+=_,f||o||l.push(u),l=l.concat(h),p=o?0:this._measureWord([u],i,d),d++,f=!1,g>m&&(m=g);return v&&a.push(l),m+n>this.dynamicMinWidth&&(this.dynamicMinWidth=m-_+n),a},isEndOfWrapping:function(e){return!this._styleMap[e+1]||this._styleMap[e+1].line!==this._styleMap[e].line},missingNewlineOffset:function(e,t){return this.splitByGrapheme&&!t?this.isEndOfWrapping(e)?1:0:1},_splitTextIntoLines:function(e){for(var i=t.Text.prototype._splitTextIntoLines.call(this,e),s=this._wrapText(i.lines,this.width),n=new Array(s.length),r=0;r{var s=i(59368),n=i(63819);e.exports=function e(t,i,r,o,a){var l=-1,c=t.length;for(r||(r=n),a||(a=[]);++l0&&r(h)?i>1?e(h,i-1,r,o,a):s(a,h):o||(a[a.length]=h)}return a}},63010:e=>{var t=Object.prototype.hasOwnProperty;e.exports=function(e,i){return null!=e&&t.call(e,i)}},80531:(e,t,i)=>{var s=i(68097),n=i(88834),r=i(12529),o=i(92061);e.exports=function(e,t){return t=s(t,e),null==(e=r(e,t))||delete e[o(n(t))]}},24410:(e,t,i)=>{var s=i(20011);e.exports=function(e){return s(e)?void 0:e}},34408:(e,t,i)=>{var s=i(73917),n=i(39069),r=i(72633);e.exports=function(e){return r(n(e,void 0,s),e+"")}},63819:(e,t,i)=>{var s=i(537),n=i(52964),r=i(19305),o=s?s.isConcatSpreadable:void 0;e.exports=function(e){return r(e)||n(e)||!!(o&&e&&e[o])}},12529:(e,t,i)=>{var s=i(43238),n=i(32112);e.exports=function(e,t){return t.length<2?e:s(e,n(t,0,-1))}},73917:(e,t,i)=>{var s=i(79064);e.exports=function(e){return(null==e?0:e.length)?s(e,1):[]}},81824:(e,t,i)=>{var s=i(63010),n=i(78326);e.exports=function(e,t){return null!=e&&n(e,t,s)}},61199:(e,t,i)=>{var s=i(16320),n=i(59698);e.exports=function(e){return"number"==typeof e||n(e)&&"[object Number]"==s(e)}},88834:e=>{e.exports=function(e){var t=null==e?0:e.length;return t?e[t-1]:void 0}},52708:(e,t,i)=>{var s=i(634),n=i(35647)((function(e,t,i,n){s(e,t,i,n)}));e.exports=n},62091:(e,t,i)=>{var s=i(54380),n=i(35367),r=i(80531),o=i(68097),a=i(62871),l=i(24410),c=i(34408),h=i(35725),d=c((function(e,t){var i={};if(null==e)return i;var c=!1;t=s(t,(function(t){return t=o(t,e),c||(c=t.length>1),t})),a(e,h(e),i),c&&(i=n(i,7,l));for(var d=t.length;d--;)r(i,t[d]);return i}));e.exports=d},1445:e=>{"use strict";e.exports=function(e){for(var t=function(e){var t,i=1+(e.length+8>>6),s=new Array(16*i);for(t=0;t<16*i;t++)s[t]=0;for(t=0;t>2]|=e.charCodeAt(t)<<(8*e.length+t)%4*8;s[t>>2]|=128<<(8*e.length+t)%4*8;var n=8*e.length;return s[16*i-2]=255&n,s[16*i-2]|=(n>>>8&255)<<8,s[16*i-2]|=(n>>>16&255)<<16,s[16*i-2]|=(n>>>24&255)<<24,s}(e),i=1732584193,s=-271733879,n=-1732584194,a=271733878,u=0;u>>1|t>>>1)<<1|(1&e|1&t)}function s(e,t){return(e>>>1^t>>>1)<<1|1&e^1&t}function n(e,t){return(e>>>1&t>>>1)<<1|1&e&t}function r(e,t){var i=(65535&e)+(65535&t);return(e>>16)+(t>>16)+(i>>16)<<16|65535&i}function o(e){var i,s="";for(i=0;i<=3;i++)s+=t.charAt(e>>8*i+4&15)+t.charAt(e>>8*i&15);return s}function a(e,t,i,s,n,o){return r((a=r(r(t,e),r(s,o)))<<(l=n)|a>>>32-l,i);var a,l}function l(e,t,s,r,o,l,c){return a(i(n(t,s),n(~t,r)),e,t,o,l,c)}function c(e,t,s,r,o,l,c){return a(i(n(t,r),n(s,~r)),e,t,o,l,c)}function h(e,t,i,n,r,o,l){return a(s(s(t,i),n),e,t,r,o,l)}function d(e,t,n,r,o,l,c){return a(s(n,i(t,~r)),e,t,o,l,c)}},80781:(e,t,i)=>{"use strict";i.r(t),i.d(t,{CancellationTokenSource:()=>Pl,Emitter:()=>Fl,KeyCode:()=>Ul,KeyMod:()=>Hl,MarkerSeverity:()=>Gl,MarkerTag:()=>jl,Position:()=>Bl,Range:()=>Wl,Selection:()=>Vl,SelectionDirection:()=>zl,Token:()=>Yl,Uri:()=>Kl,default:()=>Zl,editor:()=>ql,languages:()=>$l});var s={};i.r(s),i.d(s,{CancellationTokenSource:()=>Pl,Emitter:()=>Fl,KeyCode:()=>Ul,KeyMod:()=>Hl,MarkerSeverity:()=>Gl,MarkerTag:()=>jl,Position:()=>Bl,Range:()=>Wl,Selection:()=>Vl,SelectionDirection:()=>zl,Token:()=>Yl,Uri:()=>Kl,editor:()=>ql,languages:()=>$l});i(44915),i(88952),i(36999),i(58590),i(6438),i(94908),i(4836);var n=i(52555),r=(i(64215),i(31659),i(99822),i(40142),i(18864),i(32516),i(20961),i(40800),i(2183),i(58568),i(63867),i(61731),i(34175),i(44588),i(70552),i(48279),i(65877),i(81091),i(99312),i(62427),i(58466),i(56800),i(28449),i(57244),i(76440),i(80409),i(58145),i(40677),i(9948),i(84325),i(15040),i(75639),i(85117),i(14614),i(95200),i(50352),i(4519),i(85646),i(77047),i(6429),i(28211),i(59731),i(57377),i(50071),i(18278),i(98745),i(44798),i(10617),i(30936),i(57197),i(90870),i(10846),i(22890),i(98472),i(50166),i(68887),i(47210),i(79907),i(38728),i(46606),i(87908)),o=i(73848),a=i(25893),l=i(5662),c=i(91508),h=i(79400),d=i(28433),u=i(31450),g=i(80301),p=i(10146),m=i(90766),f=i(51929),_=i(80789),v=i(64383),C=i(36456),b=i(25890),E=i(78209);let S;function y(e,t){const i=globalThis.MonacoEnvironment;if(i){if("function"===typeof i.getWorker)return i.getWorker("workerMain.js",t);if("function"===typeof i.getWorkerUrl){const e=i.getWorkerUrl("workerMain.js",t);return new Worker(S?S.createScriptURL(e):e,{name:t,type:"module"})}}if(e){const i=function(e,t,i){const s=/^((http:)|(https:)|(file:)|(vscode-file:))/.test(t);if(s&&t.substring(0,globalThis.origin.length)!==globalThis.origin);else{const i=t.lastIndexOf("?"),s=t.lastIndexOf("#",i),n=i>0?new URLSearchParams(t.substring(i+1,~s?s:void 0)):new URLSearchParams;C.SJ.addSearchParam(n,!0,!0);t=n.toString()?`${t}?${n.toString()}#${e}`:`${t}#${e}`}0;const n=new Blob([(0,b.Yc)([`/*${e}*/`,i?`globalThis.MonacoEnvironment = { baseUrl: '${i}' };`:void 0,`globalThis._VSCODE_NLS_MESSAGES = ${JSON.stringify((0,E.Ec)())};`,`globalThis._VSCODE_NLS_LANGUAGE = ${JSON.stringify((0,E.i8)())};`,`globalThis._VSCODE_FILE_ROOT = '${globalThis._VSCODE_FILE_ROOT}';`,"const ttPolicy = globalThis.trustedTypes?.createPolicy('defaultWorkerFactory', { createScriptURL: value => value });","globalThis.workerttPolicy = ttPolicy;",`await import(ttPolicy?.createScriptURL('${t}') ?? '${t}');`,"globalThis.postMessage({ type: 'vscode-worker-ready' });",`/*${e}*/`]).join("")],{type:"application/javascript"});return URL.createObjectURL(n)}(t,e.toString(!0)),s=new Worker(S?S.createScriptURL(i):i,{name:t,type:"module"});return function(e){return new Promise(((t,i)=>{e.onmessage=function(i){"vscode-worker-ready"===i.data.type&&(e.onmessage=null,t(e))},e.onerror=i}))}(s)}throw new Error("You must define a function MonacoEnvironment.getWorkerUrl or MonacoEnvironment.getWorker")}S="object"===typeof self&&self.constructor&&"DedicatedWorkerGlobalScope"===self.constructor.name&&void 0!==globalThis.workerttPolicy?globalThis.workerttPolicy:(0,_.H)("defaultWorkerFactory",{createScriptURL:e=>e});class w extends l.jG{constructor(e,t,i,s,n,r){super(),this.id=i,this.label=s;const o=y(e,s);"function"===typeof o.then?this.worker=o:this.worker=Promise.resolve(o),this.postMessage(t,[]),this.worker.then((e=>{e.onmessage=function(e){n(e.data)},e.onmessageerror=r,"function"===typeof e.addEventListener&&e.addEventListener("error",r)})),this._register((0,l.s)((()=>{this.worker?.then((e=>{e.onmessage=null,e.onmessageerror=null,e.removeEventListener("error",r),e.terminate()})),this.worker=null})))}getId(){return this.id}postMessage(e,t){this.worker?.then((i=>{try{i.postMessage(e,t)}catch(s){(0,v.dz)(s),(0,v.dz)(new Error(`FAILED to post message to '${this.label}'-worker`,{cause:s}))}}))}}class L{constructor(e,t){this.amdModuleId=e,this.label=t,this.esmModuleLocation=C.zl.asBrowserUri(`${e}.esm.js`)}}class R{static{this.LAST_WORKER_ID=0}constructor(){this._webWorkerFailedBeforeError=!1}create(e,t,i){const s=++R.LAST_WORKER_ID;if(this._webWorkerFailedBeforeError)throw this._webWorkerFailedBeforeError;return new w(e.esmModuleLocation,e.amdModuleId,s,e.label||"anonymous"+s,t,(e=>{(0,f.logOnceWebWorkerWarning)(e),this._webWorkerFailedBeforeError=e,i(e)}))}}var T=i(36677),x=i(17469),k=i(16545),A=i(23750),N=i(90360),I=i(18801),O=i(78381),D=i(56942),M=i(41845),P=i(87723),F=i(86571),U=i(8597),H=i(47443),B=i(80718),W=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},V=function(e,t){return function(i,s){t(i,s,e)}};const z=3e5;function G(e,t){const i=e.getModel(t);return!!i&&!i.isTooLargeForSyncing()}let j=class extends l.jG{constructor(e,t,i,s,n,r){super(),this._languageConfigurationService=n,this._modelService=t,this._workerManager=this._register(new Y(e,this._modelService)),this._logService=s,this._register(r.linkProvider.register({language:"*",hasAccessToAllModels:!0},{provideLinks:async(e,t)=>{if(!G(this._modelService,e.uri))return Promise.resolve({links:[]});const i=await this._workerWithResources([e.uri]),s=await i.$computeLinks(e.uri.toString());return s&&{links:s}}})),this._register(r.completionProvider.register("*",new K(this._workerManager,i,this._modelService,this._languageConfigurationService)))}dispose(){super.dispose()}canComputeUnicodeHighlights(e){return G(this._modelService,e)}async computedUnicodeHighlights(e,t,i){return(await this._workerWithResources([e])).$computeUnicodeHighlights(e.toString(),t,i)}async computeDiff(e,t,i,s){const n=await this._workerWithResources([e,t],!0),r=await n.$computeDiff(e.toString(),t.toString(),i,s);if(!r)return null;return{identical:r.identical,quitEarly:r.quitEarly,changes:o(r.changes),moves:r.moves.map((e=>new M.t(new P.WL(new F.M(e[0],e[1]),new F.M(e[2],e[3])),o(e[4]))))};function o(e){return e.map((e=>new P.wm(new F.M(e[0],e[1]),new F.M(e[2],e[3]),e[4]?.map((e=>new P.q6(new T.Q(e[0],e[1],e[2],e[3]),new T.Q(e[4],e[5],e[6],e[7])))))))}}async computeMoreMinimalEdits(e,t,i=!1){if((0,b.EI)(t)){if(!G(this._modelService,e))return Promise.resolve(t);const s=O.W.create(),n=this._workerWithResources([e]).then((s=>s.$computeMoreMinimalEdits(e.toString(),t,i)));return n.finally((()=>this._logService.trace("FORMAT#computeMoreMinimalEdits",e.toString(!0),s.elapsed()))),Promise.race([n,(0,m.wR)(1e3).then((()=>t))])}return Promise.resolve(void 0)}canNavigateValueSet(e){return G(this._modelService,e)}async navigateValueSet(e,t,i){const s=this._modelService.getModel(e);if(!s)return null;const n=this._languageConfigurationService.getLanguageConfiguration(s.getLanguageId()).getWordDefinition(),r=n.source,o=n.flags;return(await this._workerWithResources([e])).$navigateValueSet(e.toString(),t,i,r,o)}canComputeWordRanges(e){return G(this._modelService,e)}async computeWordRanges(e,t){const i=this._modelService.getModel(e);if(!i)return Promise.resolve(null);const s=this._languageConfigurationService.getLanguageConfiguration(i.getLanguageId()).getWordDefinition(),n=s.source,r=s.flags;return(await this._workerWithResources([e])).$computeWordRanges(e.toString(),t,n,r)}async findSectionHeaders(e,t){return(await this._workerWithResources([e])).$findSectionHeaders(e.toString(),t)}async computeDefaultDocumentColors(e){return(await this._workerWithResources([e])).$computeDefaultDocumentColors(e.toString())}async _workerWithResources(e,t=!1){const i=await this._workerManager.withWorker();return await i.workerWithSyncedResources(e,t)}};j=W([V(1,A.IModelService),V(2,N.ITextResourceConfigurationService),V(3,I.rr),V(4,x.JZ),V(5,D.ILanguageFeaturesService)],j);class K{constructor(e,t,i,s){this.languageConfigurationService=s,this._debugDisplayName="wordbasedCompletions",this._workerManager=e,this._configurationService=t,this._modelService=i}async provideCompletionItems(e,t){const i=this._configurationService.getValue(e.uri,t,"editor");if("off"===i.wordBasedSuggestions)return;const s=[];if("currentDocument"===i.wordBasedSuggestions)G(this._modelService,e.uri)&&s.push(e.uri);else for(const h of this._modelService.getModels())G(this._modelService,h.uri)&&(h===e?s.unshift(h.uri):"allDocuments"!==i.wordBasedSuggestions&&h.getLanguageId()!==e.getLanguageId()||s.push(h.uri));if(0===s.length)return;const n=this.languageConfigurationService.getLanguageConfiguration(e.getLanguageId()).getWordDefinition(),r=e.getWordAtPosition(t),o=r?new T.Q(t.lineNumber,r.startColumn,t.lineNumber,r.endColumn):T.Q.fromPositions(t),a=o.setEndPosition(t.lineNumber,t.column),l=await this._workerManager.withWorker(),c=await l.textualSuggest(s,r?.word,n);return c?{duration:c.duration,suggestions:c.words.map((e=>({kind:18,label:e,insertText:e,range:{insert:a,replace:o}})))}:void 0}}let Y=class extends l.jG{constructor(e,t){super(),this._workerDescriptor=e,this._modelService=t,this._editorWorkerClient=null,this._lastWorkerUsedTime=(new Date).getTime();this._register(new U.Be).cancelAndSet((()=>this._checkStopIdleWorker()),Math.round(15e4),a.G),this._register(this._modelService.onModelRemoved((e=>this._checkStopEmptyWorker())))}dispose(){this._editorWorkerClient&&(this._editorWorkerClient.dispose(),this._editorWorkerClient=null),super.dispose()}_checkStopEmptyWorker(){if(!this._editorWorkerClient)return;0===this._modelService.getModels().length&&(this._editorWorkerClient.dispose(),this._editorWorkerClient=null)}_checkStopIdleWorker(){if(!this._editorWorkerClient)return;(new Date).getTime()-this._lastWorkerUsedTime>z&&(this._editorWorkerClient.dispose(),this._editorWorkerClient=null)}withWorker(){return this._lastWorkerUsedTime=(new Date).getTime(),this._editorWorkerClient||(this._editorWorkerClient=new $(this._workerDescriptor,!1,this._modelService)),Promise.resolve(this._editorWorkerClient)}};Y=W([V(1,A.IModelService)],Y);class q{constructor(e){this._instance=e,this.proxy=this._instance}dispose(){this._instance.dispose()}setChannel(e,t){throw new Error("Not supported")}}let $=class extends l.jG{constructor(e,t,i){super(),this._workerDescriptor=e,this._disposed=!1,this._modelService=i,this._keepIdleModels=t,this._worker=null,this._modelManager=null}fhr(e,t){throw new Error("Not implemented!")}_getOrCreateWorker(){if(!this._worker)try{this._worker=this._register(function(e,t){const i="string"===typeof e?new L(e,t):e;return new f.SimpleWorkerClient(new R,i)}(this._workerDescriptor)),B.EditorWorkerHost.setChannel(this._worker,this._createEditorWorkerHost())}catch(e){(0,f.logOnceWebWorkerWarning)(e),this._worker=this._createFallbackLocalWorker()}return this._worker}async _getProxy(){try{const e=this._getOrCreateWorker().proxy;return await e.$ping(),e}catch(e){return(0,f.logOnceWebWorkerWarning)(e),this._worker=this._createFallbackLocalWorker(),this._worker.proxy}}_createFallbackLocalWorker(){return new q(new k.EditorSimpleWorker(this._createEditorWorkerHost(),null))}_createEditorWorkerHost(){return{$fhr:(e,t)=>this.fhr(e,t)}}_getOrCreateModelManager(e){return this._modelManager||(this._modelManager=this._register(new H.WorkerTextModelSyncClient(e,this._modelService,this._keepIdleModels))),this._modelManager}async workerWithSyncedResources(e,t=!1){if(this._disposed)return Promise.reject((0,v.aD)());const i=await this._getProxy();return this._getOrCreateModelManager(i).ensureSyncedResources(e,t),i}async textualSuggest(e,t,i){const s=await this.workerWithSyncedResources(e),n=i.source,r=i.flags;return s.$textualSuggest(e.map((e=>e.toString())),t,n,r)}dispose(){super.dispose(),this._disposed=!0}};$=W([V(2,A.IModelService)],$);var Q=i(41234),X=i(58925),Z=i(47612),J=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ee=function(e,t){return function(i,s){t(i,s,e)}};let te=class extends l.jG{constructor(e){super(),this._themeService=e,this._onWillCreateCodeEditor=this._register(new Q.vl),this._onCodeEditorAdd=this._register(new Q.vl),this.onCodeEditorAdd=this._onCodeEditorAdd.event,this._onCodeEditorRemove=this._register(new Q.vl),this.onCodeEditorRemove=this._onCodeEditorRemove.event,this._onWillCreateDiffEditor=this._register(new Q.vl),this._onDiffEditorAdd=this._register(new Q.vl),this.onDiffEditorAdd=this._onDiffEditorAdd.event,this._onDiffEditorRemove=this._register(new Q.vl),this.onDiffEditorRemove=this._onDiffEditorRemove.event,this._decorationOptionProviders=new Map,this._codeEditorOpenHandlers=new X.w,this._modelProperties=new Map,this._codeEditors=Object.create(null),this._diffEditors=Object.create(null),this._globalStyleSheet=null}willCreateCodeEditor(){this._onWillCreateCodeEditor.fire()}addCodeEditor(e){this._codeEditors[e.getId()]=e,this._onCodeEditorAdd.fire(e)}removeCodeEditor(e){delete this._codeEditors[e.getId()]&&this._onCodeEditorRemove.fire(e)}listCodeEditors(){return Object.keys(this._codeEditors).map((e=>this._codeEditors[e]))}willCreateDiffEditor(){this._onWillCreateDiffEditor.fire()}addDiffEditor(e){this._diffEditors[e.getId()]=e,this._onDiffEditorAdd.fire(e)}listDiffEditors(){return Object.keys(this._diffEditors).map((e=>this._diffEditors[e]))}getFocusedCodeEditor(){let e=null;const t=this.listCodeEditors();for(const i of t){if(i.hasTextFocus())return i;i.hasWidgetFocus()&&(e=i)}return e}removeDecorationType(e){const t=this._decorationOptionProviders.get(e);t&&(t.refCount--,t.refCount<=0&&(this._decorationOptionProviders.delete(e),t.dispose(),this.listCodeEditors().forEach((t=>t.removeDecorationsByType(e)))))}setModelProperty(e,t,i){const s=e.toString();let n;this._modelProperties.has(s)?n=this._modelProperties.get(s):(n=new Map,this._modelProperties.set(s,n)),n.set(t,i)}getModelProperty(e,t){const i=e.toString();if(this._modelProperties.has(i)){return this._modelProperties.get(i).get(t)}}async openCodeEditor(e,t,i){for(const s of this._codeEditorOpenHandlers){const n=await s(e,t,i);if(null!==n)return n}return null}registerCodeEditorOpenHandler(e){const t=this._codeEditorOpenHandlers.unshift(e);return(0,l.s)(t)}};te=J([ee(0,Z.Gy)],te);var ie=i(32848),se=i(14718),ne=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},re=function(e,t){return function(i,s){t(i,s,e)}};let oe=class extends te{constructor(e,t){super(t),this._register(this.onCodeEditorAdd((()=>this._checkContextKey()))),this._register(this.onCodeEditorRemove((()=>this._checkContextKey()))),this._editorIsOpen=e.createKey("editorIsOpen",!1),this._activeCodeEditor=null,this._register(this.registerCodeEditorOpenHandler((async(e,t,i)=>t?this.doOpenEditor(t,e):null)))}_checkContextKey(){let e=!1;for(const t of this.listCodeEditors())if(!t.isSimpleWidget){e=!0;break}this._editorIsOpen.set(e)}setActiveCodeEditor(e){this._activeCodeEditor=e}getActiveCodeEditor(){return this._activeCodeEditor}doOpenEditor(e,t){if(!this.findModel(e,t.resource)){if(t.resource){const i=t.resource.scheme;if(i===C.ny.http||i===C.ny.https)return(0,U.CE)(t.resource.toString()),e}return null}const i=t.options?t.options.selection:null;if(i)if("number"===typeof i.endLineNumber&&"number"===typeof i.endColumn)e.setSelection(i),e.revealRangeInCenter(i,1);else{const t={lineNumber:i.startLineNumber,column:i.startColumn};e.setPosition(t),e.revealPositionInCenter(t,1)}return e}findModel(e,t){const i=e.getModel();return i&&i.uri.toString()!==t.toString()?null:i}};oe=ne([re(0,ie.fN),re(1,Z.Gy)],oe),(0,se.v)(g.T,oe,0);var ae=i(63591);const le=(0,ae.u1)("layoutService");var ce=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},he=function(e,t){return function(i,s){t(i,s,e)}};let de=class{get mainContainer(){return(0,b.Fy)(this._codeEditorService.listCodeEditors())?.getContainerDomNode()??a.G.document.body}get activeContainer(){const e=this._codeEditorService.getFocusedCodeEditor()??this._codeEditorService.getActiveCodeEditor();return e?.getContainerDomNode()??this.mainContainer}get mainContainerDimension(){return U.tG(this.mainContainer)}get activeContainerDimension(){return U.tG(this.activeContainer)}get containers(){return(0,b.Yc)(this._codeEditorService.listCodeEditors().map((e=>e.getContainerDomNode())))}getContainer(){return this.activeContainer}whenContainerStylesLoaded(){}focus(){this._codeEditorService.getFocusedCodeEditor()?.focus()}constructor(e){this._codeEditorService=e,this.onDidLayoutMainContainer=Q.Jh.None,this.onDidLayoutActiveContainer=Q.Jh.None,this.onDidLayoutContainer=Q.Jh.None,this.onDidChangeActiveContainer=Q.Jh.None,this.onDidAddContainer=Q.Jh.None,this.mainContainerOffset={top:0,quickPickTop:0},this.activeContainerOffset={top:0,quickPickTop:0}}};de=ce([he(0,g.T)],de);let ue=class extends de{get mainContainer(){return this._container}constructor(e,t){super(t),this._container=e}};ue=ce([he(1,g.T)],ue),(0,se.v)(le,de,1);var ge=i(42291),pe=i(59599),me=i(58591),fe=i(47579),_e=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ve=function(e,t){return function(i,s){t(i,s,e)}};const Ce=!1;function be(e){return e.scheme===C.ny.file?e.fsPath:e.path}let Ee=0;class Se{constructor(e,t,i,s,n,r,o){this.id=++Ee,this.type=0,this.actual=e,this.label=e.label,this.confirmBeforeUndo=e.confirmBeforeUndo||!1,this.resourceLabel=t,this.strResource=i,this.resourceLabels=[this.resourceLabel],this.strResources=[this.strResource],this.groupId=s,this.groupOrder=n,this.sourceId=r,this.sourceOrder=o,this.isValid=!0}setValid(e){this.isValid=e}toString(){return`[id:${this.id}] [group:${this.groupId}] [${this.isValid?" VALID":"INVALID"}] ${this.actual.constructor.name} - ${this.actual}`}}class ye{constructor(e,t){this.resourceLabel=e,this.reason=t}}class we{constructor(){this.elements=new Map}createMessage(){const e=[],t=[];for(const[,s]of this.elements){(0===s.reason?e:t).push(s.resourceLabel)}const i=[];return e.length>0&&i.push(E.kg({key:"externalRemoval",comment:["{0} is a list of filenames"]},"The following files have been closed and modified on disk: {0}.",e.join(", "))),t.length>0&&i.push(E.kg({key:"noParallelUniverses",comment:["{0} is a list of filenames"]},"The following files have been modified in an incompatible way: {0}.",t.join(", "))),i.join("\n")}get size(){return this.elements.size}has(e){return this.elements.has(e)}set(e,t){this.elements.set(e,t)}delete(e){return this.elements.delete(e)}}class Le{constructor(e,t,i,s,n,r,o){this.id=++Ee,this.type=1,this.actual=e,this.label=e.label,this.confirmBeforeUndo=e.confirmBeforeUndo||!1,this.resourceLabels=t,this.strResources=i,this.groupId=s,this.groupOrder=n,this.sourceId=r,this.sourceOrder=o,this.removedResources=null,this.invalidatedResources=null}canSplit(){return"function"===typeof this.actual.split}removeResource(e,t,i){this.removedResources||(this.removedResources=new we),this.removedResources.has(t)||this.removedResources.set(t,new ye(e,i))}setValid(e,t,i){i?this.invalidatedResources&&(this.invalidatedResources.delete(t),0===this.invalidatedResources.size&&(this.invalidatedResources=null)):(this.invalidatedResources||(this.invalidatedResources=new we),this.invalidatedResources.has(t)||this.invalidatedResources.set(t,new ye(e,0)))}toString(){return`[id:${this.id}] [group:${this.groupId}] [${this.invalidatedResources?"INVALID":" VALID"}] ${this.actual.constructor.name} - ${this.actual}`}}class Re{constructor(e,t){this.resourceLabel=e,this.strResource=t,this._past=[],this._future=[],this.locked=!1,this.versionId=1}dispose(){for(const e of this._past)1===e.type&&e.removeResource(this.resourceLabel,this.strResource,0);for(const e of this._future)1===e.type&&e.removeResource(this.resourceLabel,this.strResource,0);this.versionId++}toString(){const e=[];e.push(`* ${this.strResource}:`);for(let t=0;t=0;t--)e.push(` * [REDO] ${this._future[t]}`);return e.join("\n")}flushAllElements(){this._past=[],this._future=[],this.versionId++}_setElementValidFlag(e,t){1===e.type?e.setValid(this.resourceLabel,this.strResource,t):e.setValid(t)}setElementsValidFlag(e,t){for(const i of this._past)t(i.actual)&&this._setElementValidFlag(i,e);for(const i of this._future)t(i.actual)&&this._setElementValidFlag(i,e)}pushElement(e){for(const t of this._future)1===t.type&&t.removeResource(this.resourceLabel,this.strResource,1);this._future=[],this._past.push(e),this.versionId++}createSnapshot(e){const t=[];for(let i=0,s=this._past.length;i=0;i--)t.push(this._future[i].id);return new fe.To(e,t)}restoreSnapshot(e){const t=e.elements.length;let i=!0,s=0,n=-1;for(let o=0,a=this._past.length;o=t||r.id!==e.elements[s])&&(i=!1,n=0),i||1!==r.type||r.removeResource(this.resourceLabel,this.strResource,0)}let r=-1;for(let o=this._future.length-1;o>=0;o--,s++){const n=this._future[o];i&&(s>=t||n.id!==e.elements[s])&&(i=!1,r=o),i||1!==n.type||n.removeResource(this.resourceLabel,this.strResource,0)}-1!==n&&(this._past=this._past.slice(0,n)),-1!==r&&(this._future=this._future.slice(r+1)),this.versionId++}getElements(){const e=[],t=[];for(const i of this._past)e.push(i.actual);for(const i of this._future)t.push(i.actual);return{past:e,future:t}}getClosestPastElement(){return 0===this._past.length?null:this._past[this._past.length-1]}getSecondClosestPastElement(){return this._past.length<2?null:this._past[this._past.length-2]}getClosestFutureElement(){return 0===this._future.length?null:this._future[this._future.length-1]}hasPastElements(){return this._past.length>0}hasFutureElements(){return this._future.length>0}splitPastWorkspaceElement(e,t){for(let i=this._past.length-1;i>=0;i--)if(this._past[i]===e){t.has(this.strResource)?this._past[i]=t.get(this.strResource):this._past.splice(i,1);break}this.versionId++}splitFutureWorkspaceElement(e,t){for(let i=this._future.length-1;i>=0;i--)if(this._future[i]===e){t.has(this.strResource)?this._future[i]=t.get(this.strResource):this._future.splice(i,1);break}this.versionId++}moveBackward(e){this._past.pop(),this._future.push(e),this.versionId++}moveForward(e){this._future.pop(),this._past.push(e),this.versionId++}}class Te{constructor(e){this.editStacks=e,this._versionIds=[];for(let t=0,i=this.editStacks.length;tt.sourceOrder)&&(t=r,i=s))}return[t,i]}canUndo(e){if(e instanceof fe.Ym){const[,t]=this._findClosestUndoElementWithSource(e.id);return!!t}const t=this.getUriComparisonKey(e);if(this._editStacks.has(t)){return this._editStacks.get(t).hasPastElements()}return!1}_onError(e,t){(0,v.dz)(e);for(const i of t.strResources)this.removeElements(i);this._notificationService.error(e)}_acquireLocks(e){for(const t of e.editStacks)if(t.locked)throw new Error("Cannot acquire edit stack lock");for(const t of e.editStacks)t.locked=!0;return()=>{for(const t of e.editStacks)t.locked=!1}}_safeInvokeWithLocks(e,t,i,s,n){const r=this._acquireLocks(i);let o;try{o=t()}catch(a){return r(),s.dispose(),this._onError(a,e)}return o?o.then((()=>(r(),s.dispose(),n())),(t=>(r(),s.dispose(),this._onError(t,e)))):(r(),s.dispose(),n())}async _invokeWorkspacePrepare(e){if("undefined"===typeof e.actual.prepareUndoRedo)return l.jG.None;const t=e.actual.prepareUndoRedo();return"undefined"===typeof t?l.jG.None:t}_invokeResourcePrepare(e,t){if(1!==e.actual.type||"undefined"===typeof e.actual.prepareUndoRedo)return t(l.jG.None);const i=e.actual.prepareUndoRedo();return i?(0,l.Xm)(i)?t(i):i.then((e=>t(e))):t(l.jG.None)}_getAffectedEditStacks(e){const t=[];for(const i of e.strResources)t.push(this._editStacks.get(i)||xe);return new Te(t)}_tryToSplitAndUndo(e,t,i,s){if(t.canSplit())return this._splitPastWorkspaceElement(t,i),this._notificationService.warn(s),new Ae(this._undo(e,0,!0));for(const n of t.strResources)this.removeElements(n);return this._notificationService.warn(s),new Ae}_checkWorkspaceUndo(e,t,i,s){if(t.removedResources)return this._tryToSplitAndUndo(e,t,t.removedResources,E.kg({key:"cannotWorkspaceUndo",comment:["{0} is a label for an operation. {1} is another message."]},"Could not undo '{0}' across all files. {1}",t.label,t.removedResources.createMessage()));if(s&&t.invalidatedResources)return this._tryToSplitAndUndo(e,t,t.invalidatedResources,E.kg({key:"cannotWorkspaceUndo",comment:["{0} is a label for an operation. {1} is another message."]},"Could not undo '{0}' across all files. {1}",t.label,t.invalidatedResources.createMessage()));const n=[];for(const o of i.editStacks)o.getClosestPastElement()!==t&&n.push(o.resourceLabel);if(n.length>0)return this._tryToSplitAndUndo(e,t,null,E.kg({key:"cannotWorkspaceUndoDueToChanges",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not undo '{0}' across all files because changes were made to {1}",t.label,n.join(", ")));const r=[];for(const o of i.editStacks)o.locked&&r.push(o.resourceLabel);return r.length>0?this._tryToSplitAndUndo(e,t,null,E.kg({key:"cannotWorkspaceUndoDueToInProgressUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not undo '{0}' across all files because there is already an undo or redo operation running on {1}",t.label,r.join(", "))):i.isValid()?null:this._tryToSplitAndUndo(e,t,null,E.kg({key:"cannotWorkspaceUndoDueToInMeantimeUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not undo '{0}' across all files because an undo or redo operation occurred in the meantime",t.label))}_workspaceUndo(e,t,i){const s=this._getAffectedEditStacks(t),n=this._checkWorkspaceUndo(e,t,s,!1);return n?n.returnValue:this._confirmAndExecuteWorkspaceUndo(e,t,s,i)}_isPartOfUndoGroup(e){if(!e.groupId)return!1;for(const[,t]of this._editStacks){const i=t.getClosestPastElement();if(i){if(i===e){const i=t.getSecondClosestPastElement();if(i&&i.groupId===e.groupId)return!0}if(i.groupId===e.groupId)return!0}}return!1}async _confirmAndExecuteWorkspaceUndo(e,t,i,s){if(t.canSplit()&&!this._isPartOfUndoGroup(t)){let n;!function(e){e[e.All=0]="All",e[e.This=1]="This",e[e.Cancel=2]="Cancel"}(n||(n={}));const{result:r}=await this._dialogService.prompt({type:ge.A.Info,message:E.kg("confirmWorkspace","Would you like to undo '{0}' across all files?",t.label),buttons:[{label:E.kg({key:"ok",comment:["{0} denotes a number that is > 1, && denotes a mnemonic"]},"&&Undo in {0} Files",i.editStacks.length),run:()=>n.All},{label:E.kg({key:"nok",comment:["&& denotes a mnemonic"]},"Undo this &&File"),run:()=>n.This}],cancelButton:{run:()=>n.Cancel}});if(r===n.Cancel)return;if(r===n.This)return this._splitPastWorkspaceElement(t,null),this._undo(e,0,!0);const o=this._checkWorkspaceUndo(e,t,i,!1);if(o)return o.returnValue;s=!0}let n;try{n=await this._invokeWorkspacePrepare(t)}catch(o){return this._onError(o,t)}const r=this._checkWorkspaceUndo(e,t,i,!0);if(r)return n.dispose(),r.returnValue;for(const a of i.editStacks)a.moveBackward(t);return this._safeInvokeWithLocks(t,(()=>t.actual.undo()),i,n,(()=>this._continueUndoInGroup(t.groupId,s)))}_resourceUndo(e,t,i){if(t.isValid){if(!e.locked)return this._invokeResourcePrepare(t,(s=>(e.moveBackward(t),this._safeInvokeWithLocks(t,(()=>t.actual.undo()),new Te([e]),s,(()=>this._continueUndoInGroup(t.groupId,i))))));{const e=E.kg({key:"cannotResourceUndoDueToInProgressUndoRedo",comment:["{0} is a label for an operation."]},"Could not undo '{0}' because there is already an undo or redo operation running.",t.label);this._notificationService.warn(e)}}else e.flushAllElements()}_findClosestUndoElementInGroup(e){if(!e)return[null,null];let t=null,i=null;for(const[s,n]of this._editStacks){const r=n.getClosestPastElement();r&&(r.groupId===e&&(!t||r.groupOrder>t.groupOrder)&&(t=r,i=s))}return[t,i]}_continueUndoInGroup(e,t){if(!e)return;const[,i]=this._findClosestUndoElementInGroup(e);return i?this._undo(i,0,t):void 0}undo(e){if(e instanceof fe.Ym){const[,t]=this._findClosestUndoElementWithSource(e.id);return t?this._undo(t,e.id,!1):void 0}return"string"===typeof e?this._undo(e,0,!1):this._undo(this.getUriComparisonKey(e),0,!1)}_undo(e,t=0,i){if(!this._editStacks.has(e))return;const s=this._editStacks.get(e),n=s.getClosestPastElement();if(!n)return;if(n.groupId){const[e,s]=this._findClosestUndoElementInGroup(n.groupId);if(n!==e&&s)return this._undo(s,t,i)}if((n.sourceId!==t||n.confirmBeforeUndo)&&!i)return this._confirmAndContinueUndo(e,t,n);try{return 1===n.type?this._workspaceUndo(e,n,i):this._resourceUndo(s,n,i)}finally{Ce}}async _confirmAndContinueUndo(e,t,i){if((await this._dialogService.confirm({message:E.kg("confirmDifferentSource","Would you like to undo '{0}'?",i.label),primaryButton:E.kg({key:"confirmDifferentSource.yes",comment:["&& denotes a mnemonic"]},"&&Yes"),cancelButton:E.kg("confirmDifferentSource.no","No")})).confirmed)return this._undo(e,t,!0)}_findClosestRedoElementWithSource(e){if(!e)return[null,null];let t=null,i=null;for(const[s,n]of this._editStacks){const r=n.getClosestFutureElement();r&&(r.sourceId===e&&(!t||r.sourceOrder0)return this._tryToSplitAndRedo(e,t,null,E.kg({key:"cannotWorkspaceRedoDueToChanges",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not redo '{0}' across all files because changes were made to {1}",t.label,n.join(", ")));const r=[];for(const o of i.editStacks)o.locked&&r.push(o.resourceLabel);return r.length>0?this._tryToSplitAndRedo(e,t,null,E.kg({key:"cannotWorkspaceRedoDueToInProgressUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not redo '{0}' across all files because there is already an undo or redo operation running on {1}",t.label,r.join(", "))):i.isValid()?null:this._tryToSplitAndRedo(e,t,null,E.kg({key:"cannotWorkspaceRedoDueToInMeantimeUndoRedo",comment:["{0} is a label for an operation. {1} is a list of filenames."]},"Could not redo '{0}' across all files because an undo or redo operation occurred in the meantime",t.label))}_workspaceRedo(e,t){const i=this._getAffectedEditStacks(t),s=this._checkWorkspaceRedo(e,t,i,!1);return s?s.returnValue:this._executeWorkspaceRedo(e,t,i)}async _executeWorkspaceRedo(e,t,i){let s;try{s=await this._invokeWorkspacePrepare(t)}catch(r){return this._onError(r,t)}const n=this._checkWorkspaceRedo(e,t,i,!0);if(n)return s.dispose(),n.returnValue;for(const o of i.editStacks)o.moveForward(t);return this._safeInvokeWithLocks(t,(()=>t.actual.redo()),i,s,(()=>this._continueRedoInGroup(t.groupId)))}_resourceRedo(e,t){if(t.isValid){if(!e.locked)return this._invokeResourcePrepare(t,(i=>(e.moveForward(t),this._safeInvokeWithLocks(t,(()=>t.actual.redo()),new Te([e]),i,(()=>this._continueRedoInGroup(t.groupId))))));{const e=E.kg({key:"cannotResourceRedoDueToInProgressUndoRedo",comment:["{0} is a label for an operation."]},"Could not redo '{0}' because there is already an undo or redo operation running.",t.label);this._notificationService.warn(e)}}else e.flushAllElements()}_findClosestRedoElementInGroup(e){if(!e)return[null,null];let t=null,i=null;for(const[s,n]of this._editStacks){const r=n.getClosestFutureElement();r&&(r.groupId===e&&(!t||r.groupOrder=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},je=function(e,t){return function(i,s){t(i,s,e)}};const Ke=U.$;let Ye=class extends Fe.x{get _targetWindow(){return U.zk(this._target.targetElements[0])}get _targetDocumentElement(){return U.zk(this._target.targetElements[0]).document.documentElement}get isDisposed(){return this._isDisposed}get isMouseIn(){return this._lockMouseTracker.isMouseIn}get domNode(){return this._hover.containerDomNode}get onDispose(){return this._onDispose.event}get onRequestLayout(){return this._onRequestLayout.event}get anchor(){return 2===this._hoverPosition?0:1}get x(){return this._x}get y(){return this._y}get isLocked(){return this._isLocked}set isLocked(e){this._isLocked!==e&&(this._isLocked=e,this._hoverContainer.classList.toggle("locked",this._isLocked))}constructor(e,t,i,s,n,o){super(),this._keybindingService=t,this._configurationService=i,this._openerService=s,this._instantiationService=n,this._accessibilityService=o,this._messageListeners=new l.Cm,this._isDisposed=!1,this._forcePosition=!1,this._x=0,this._y=0,this._isLocked=!1,this._enableFocusTraps=!1,this._addedFocusTrap=!1,this._onDispose=this._register(new Q.vl),this._onRequestLayout=this._register(new Q.vl),this._linkHandler=e.linkHandler||(t=>(0,He.i)(this._openerService,t,(0,Be.VS)(e.content)?e.content.isTrusted:void 0)),this._target="targetElements"in e.target?e.target:new $e(e.target),this._hoverPointer=e.appearance?.showPointer?Ke("div.workbench-hover-pointer"):void 0,this._hover=this._register(new Pe.N4),this._hover.containerDomNode.classList.add("workbench-hover","fadeIn"),e.appearance?.compact&&this._hover.containerDomNode.classList.add("workbench-hover","compact"),e.appearance?.skipFadeInAnimation&&this._hover.containerDomNode.classList.add("skip-fade-in"),e.additionalClasses&&this._hover.containerDomNode.classList.add(...e.additionalClasses),e.position?.forcePosition&&(this._forcePosition=!0),e.trapFocus&&(this._enableFocusTraps=!0),this._hoverPosition=e.position?.hoverPosition??3,this.onmousedown(this._hover.containerDomNode,(e=>e.stopPropagation())),this.onkeydown(this._hover.containerDomNode,(e=>{e.equals(9)&&this.dispose()})),this._register(U.ko(this._targetWindow,"blur",(()=>this.dispose())));const a=Ke("div.hover-row.markdown-hover"),c=Ke("div.hover-contents");if("string"===typeof e.content)c.textContent=e.content,c.style.whiteSpace="pre-wrap";else if(U.sb(e.content))c.appendChild(e.content),c.classList.add("html-hover-contents");else{const t=e.content,i=this._instantiationService.createInstance(He.T,{codeBlockFontFamily:this._configurationService.getValue("editor").fontFamily||r.jU.fontFamily}),{element:s}=i.render(t,{actionHandler:{callback:e=>this._linkHandler(e),disposables:this._messageListeners},asyncRenderCallback:()=>{c.classList.add("code-hover-contents"),this.layout(),this._onRequestLayout.fire()}});c.appendChild(s)}if(a.appendChild(c),this._hover.contentsDomNode.appendChild(a),e.actions&&e.actions.length>0){const t=Ke("div.hover-row.status-bar"),i=Ke("div.actions");e.actions.forEach((e=>{const t=this._keybindingService.lookupKeybinding(e.commandId),s=t?t.getLabel():null;Pe.jQ.render(i,{label:e.label,commandId:e.commandId,run:t=>{e.run(t),this.dispose()},iconClass:e.iconClass},s)})),t.appendChild(i),this._hover.containerDomNode.appendChild(t)}let h;if(this._hoverContainer=Ke("div.workbench-hover-container"),this._hoverPointer&&this._hoverContainer.appendChild(this._hoverPointer),this._hoverContainer.appendChild(this._hover.containerDomNode),h=!(e.actions&&e.actions.length>0)&&(void 0===e.persistence?.hideOnHover?"string"===typeof e.content||(0,Be.VS)(e.content)&&!e.content.value.includes("](")&&!e.content.value.includes(""):e.persistence.hideOnHover),e.appearance?.showHoverHint){const e=Ke("div.hover-row.status-bar"),t=Ke("div.info");t.textContent=(0,E.kg)("hoverhint","Hold {0} key to mouse over",We.zx?"Option":"Alt"),e.appendChild(t),this._hover.containerDomNode.appendChild(e)}const d=[...this._target.targetElements];h||d.push(this._hoverContainer);const u=this._register(new qe(d));if(this._register(u.onMouseOut((()=>{this._isLocked||this.dispose()}))),h){const e=[...this._target.targetElements,this._hoverContainer];this._lockMouseTracker=this._register(new qe(e)),this._register(this._lockMouseTracker.onMouseOut((()=>{this._isLocked||this.dispose()})))}else this._lockMouseTracker=u}addFocusTrap(){if(!this._enableFocusTraps||this._addedFocusTrap)return;this._addedFocusTrap=!0;const e=this._hover.containerDomNode,t=this.findLastFocusableChild(this._hover.containerDomNode);if(t){const i=U.Hs(this._hoverContainer,Ke("div")),s=U.BC(this._hoverContainer,Ke("div"));i.tabIndex=0,s.tabIndex=0,this._register(U.ko(s,"focus",(t=>{e.focus(),t.preventDefault()}))),this._register(U.ko(i,"focus",(e=>{t.focus(),e.preventDefault()})))}}findLastFocusableChild(e){if(e.hasChildNodes())for(let t=0;t=0)return e}const s=this.findLastFocusableChild(i);if(s)return s}}render(e){e.appendChild(this._hoverContainer);const t=this._hoverContainer.contains(this._hoverContainer.ownerDocument.activeElement)&&(0,Pe.vr)(!0===this._configurationService.getValue("accessibility.verbosity.hover")&&this._accessibilityService.isScreenReaderOptimized(),this._keybindingService.lookupKeybinding("editor.action.accessibleView")?.getAriaLabel());t&&(0,ze.h5)(t),this.layout(),this.addFocusTrap()}layout(){this._hover.containerDomNode.classList.remove("right-aligned"),this._hover.contentsDomNode.style.maxHeight="";const e=this._target.targetElements.map((e=>(e=>{const t=U.mU(e),i=e.getBoundingClientRect();return{top:i.top*t,bottom:i.bottom*t,right:i.right*t,left:i.left*t}})(e))),{top:t,right:i,bottom:s,left:n}=e[0],r=i-n,o=s-t,a={top:t,right:i,bottom:s,left:n,width:r,height:o,center:{x:n+r/2,y:t+o/2}};if(this.adjustHorizontalHoverPosition(a),this.adjustVerticalHoverPosition(a),this.adjustHoverMaxHeight(a),this._hoverContainer.style.padding="",this._hoverContainer.style.margin="",this._hoverPointer){switch(this._hoverPosition){case 1:a.left+=3,a.right+=3,this._hoverContainer.style.paddingLeft="3px",this._hoverContainer.style.marginLeft="-3px";break;case 0:a.left-=3,a.right-=3,this._hoverContainer.style.paddingRight="3px",this._hoverContainer.style.marginRight="-3px";break;case 2:a.top+=3,a.bottom+=3,this._hoverContainer.style.paddingTop="3px",this._hoverContainer.style.marginTop="-3px";break;case 3:a.top-=3,a.bottom-=3,this._hoverContainer.style.paddingBottom="3px",this._hoverContainer.style.marginBottom="-3px"}a.center.x=a.left+r/2,a.center.y=a.top+o/2}this.computeXCordinate(a),this.computeYCordinate(a),this._hoverPointer&&(this._hoverPointer.classList.remove("top"),this._hoverPointer.classList.remove("left"),this._hoverPointer.classList.remove("right"),this._hoverPointer.classList.remove("bottom"),this.setHoverPointerPosition(a)),this._hover.onContentsChanged()}computeXCordinate(e){const t=this._hover.containerDomNode.clientWidth+2;void 0!==this._target.x?this._x=this._target.x:1===this._hoverPosition?this._x=e.right:0===this._hoverPosition?this._x=e.left-t:(this._hoverPointer?this._x=e.center.x-this._hover.containerDomNode.clientWidth/2:this._x=e.left,this._x+t>=this._targetDocumentElement.clientWidth&&(this._hover.containerDomNode.classList.add("right-aligned"),this._x=Math.max(this._targetDocumentElement.clientWidth-t-2,this._targetDocumentElement.clientLeft))),this._xthis._targetWindow.innerHeight&&(this._y=e.bottom)}adjustHorizontalHoverPosition(e){if(void 0!==this._target.x)return;const t=this._hoverPointer?3:0;if(this._forcePosition){const i=t+2;1===this._hoverPosition?this._hover.containerDomNode.style.maxWidth=this._targetDocumentElement.clientWidth-e.right-i+"px":0===this._hoverPosition&&(this._hover.containerDomNode.style.maxWidth=e.left-i+"px")}else if(1===this._hoverPosition){if(this._targetDocumentElement.clientWidth-e.right=this._hover.containerDomNode.clientWidth+t?this._hoverPosition=0:this._hoverPosition=2}}else if(0===this._hoverPosition){if(e.left=this._hover.containerDomNode.clientWidth+t?this._hoverPosition=1:this._hoverPosition=2}e.left-this._hover.containerDomNode.clientWidth-t<=this._targetDocumentElement.clientLeft&&(this._hoverPosition=1)}}adjustVerticalHoverPosition(e){if(void 0!==this._target.y||this._forcePosition)return;const t=this._hoverPointer?3:0;3===this._hoverPosition?e.top-this._hover.containerDomNode.clientHeight-t<0&&(this._hoverPosition=2):2===this._hoverPosition&&e.bottom+this._hover.containerDomNode.clientHeight+t>this._targetWindow.innerHeight&&(this._hoverPosition=3)}adjustHoverMaxHeight(e){let t=this._targetWindow.innerHeight/2;if(this._forcePosition){const i=2+(this._hoverPointer?3:0);3===this._hoverPosition?t=Math.min(t,e.top-i):2===this._hoverPosition&&(t=Math.min(t,this._targetWindow.innerHeight-e.bottom-i))}if(this._hover.containerDomNode.style.maxHeight=`${t}px`,this._hover.contentsDomNode.clientHeighte.height?this._hoverPointer.style.top=e.center.y-(this._y-t)-3+"px":this._hoverPointer.style.top=Math.round(t/2)-3+"px";break}case 3:case 2:{this._hoverPointer.classList.add(3===this._hoverPosition?"bottom":"top");const t=this._hover.containerDomNode.clientWidth;let i=Math.round(t/2)-3;const s=this._x+i;(se.right)&&(i=e.center.x-this._x-3),this._hoverPointer.style.left=`${i}px`;break}}}focus(){this._hover.containerDomNode.focus()}dispose(){this._isDisposed||(this._onDispose.fire(),this._hoverContainer.remove(),this._messageListeners.dispose(),this._target.dispose(),super.dispose()),this._isDisposed=!0}};Ye=Ge([je(1,De.b),je(2,Me.pG),je(3,Ue.C),je(4,ae._Y),je(5,Ve.j)],Ye);class qe extends Fe.x{get onMouseOut(){return this._onMouseOut.event}get isMouseIn(){return this._isMouseIn}constructor(e){super(),this._elements=e,this._isMouseIn=!0,this._onMouseOut=this._register(new Q.vl),this._elements.forEach((e=>this.onmouseover(e,(()=>this._onTargetMouseOver(e))))),this._elements.forEach((e=>this.onmouseleave(e,(()=>this._onTargetMouseLeave(e)))))}_onTargetMouseOver(e){this._isMouseIn=!0,this._clearEvaluateMouseStateTimeout(e)}_onTargetMouseLeave(e){this._isMouseIn=!1,this._evaluateMouseState(e)}_evaluateMouseState(e){this._clearEvaluateMouseStateTimeout(e),this._mouseTimeout=U.zk(e).setTimeout((()=>this._fireIfMouseOutside()),0)}_clearEvaluateMouseStateTimeout(e){this._mouseTimeout&&(U.zk(e).clearTimeout(this._mouseTimeout),this._mouseTimeout=void 0)}_fireIfMouseOutside(){this._isMouseIn||this._onMouseOut.fire()}}class $e{constructor(e){this._element=e,this.targetElements=[this._element]}dispose(){}}var Qe,Xe=i(72962),Ze=i(55089),Je=i(92719);function et(e,t,i){const s=i.mode===Qe.ALIGN?i.offset:i.offset+i.size,n=i.mode===Qe.ALIGN?i.offset+i.size:i.offset;return 0===i.position?t<=e-s?s:t<=n?n-t:Math.max(e-t,0):t<=n?n-t:t<=e-s?s:0}!function(e){e[e.AVOID=0]="AVOID",e[e.ALIGN=1]="ALIGN"}(Qe||(Qe={}));class tt extends l.jG{static{this.BUBBLE_UP_EVENTS=["click","keydown","focus","blur"]}static{this.BUBBLE_DOWN_EVENTS=["click"]}constructor(e,t){super(),this.container=null,this.useFixedPosition=!1,this.useShadowDOM=!1,this.delegate=null,this.toDisposeOnClean=l.jG.None,this.toDisposeOnSetContainer=l.jG.None,this.shadowRoot=null,this.shadowRootHostElement=null,this.view=U.$(".context-view"),U.jD(this.view),this.setContainer(e,t),this._register((0,l.s)((()=>this.setContainer(null,1))))}setContainer(e,t){this.useFixedPosition=1!==t;const i=this.useShadowDOM;if(this.useShadowDOM=3===t,(e!==this.container||i!==this.useShadowDOM)&&(this.container&&(this.toDisposeOnSetContainer.dispose(),this.view.remove(),this.shadowRoot&&(this.shadowRoot=null,this.shadowRootHostElement?.remove(),this.shadowRootHostElement=null),this.container=null),e)){if(this.container=e,this.useShadowDOM){this.shadowRootHostElement=U.$(".shadow-root-host"),this.container.appendChild(this.shadowRootHostElement),this.shadowRoot=this.shadowRootHostElement.attachShadow({mode:"open"});const e=document.createElement("style");e.textContent=it,this.shadowRoot.appendChild(e),this.shadowRoot.appendChild(this.view),this.shadowRoot.appendChild(U.$("slot"))}else this.container.appendChild(this.view);const t=new l.Cm;tt.BUBBLE_UP_EVENTS.forEach((e=>{t.add(U.b2(this.container,e,(e=>{this.onDOMEvent(e,!1)})))})),tt.BUBBLE_DOWN_EVENTS.forEach((e=>{t.add(U.b2(this.container,e,(e=>{this.onDOMEvent(e,!0)}),!0))})),this.toDisposeOnSetContainer=t}}show(e){this.isVisible()&&this.hide(),U.w_(this.view),this.view.className="context-view monaco-component",this.view.style.top="0px",this.view.style.left="0px",this.view.style.zIndex=`${2575+(e.layer??0)}`,this.view.style.position=this.useFixedPosition?"fixed":"absolute",U.WU(this.view),this.toDisposeOnClean=e.render(this.view)||l.jG.None,this.delegate=e,this.doLayout(),this.delegate.focus?.()}getViewElement(){return this.view}layout(){this.isVisible()&&(!1!==this.delegate.canRelayout||We.un&&Ze.e.pointerEvents?(this.delegate?.layout?.(),this.doLayout()):this.hide())}doLayout(){if(!this.isVisible())return;const e=this.delegate.getAnchor();let t;if(U.sb(e)){const i=U.BK(e),s=U.mU(e);t={top:i.top*s,left:i.left*s,width:i.width*s,height:i.height*s}}else t=function(e){const t=e;return!!t&&"number"===typeof t.x&&"number"===typeof t.y}(e)?{top:e.y,left:e.x,width:e.width||1,height:e.height||2}:{top:e.posy,left:e.posx,width:2,height:2};const i=U.Tr(this.view),s=U.OK(this.view),n=this.delegate.anchorPosition||0,r=this.delegate.anchorAlignment||0,o=this.delegate.anchorAxisAlignment||0;let a,l;const c=U.fz();if(0===o){const e={offset:t.top-c.pageYOffset,size:t.height,position:0===n?0:1},o={offset:t.left,size:t.width,position:0===r?0:1,mode:Qe.ALIGN};a=et(c.innerHeight,s,e)+c.pageYOffset,Je.Q.intersects({start:a,end:a+s},{start:e.offset,end:e.offset+e.size})&&(o.mode=Qe.AVOID),l=et(c.innerWidth,i,o)}else{const e={offset:t.left,size:t.width,position:0===r?0:1},o={offset:t.top,size:t.height,position:0===n?0:1,mode:Qe.ALIGN};l=et(c.innerWidth,i,e),Je.Q.intersects({start:l,end:l+i},{start:e.offset,end:e.offset+e.size})&&(o.mode=Qe.AVOID),a=et(c.innerHeight,s,o)+c.pageYOffset}this.view.classList.remove("top","bottom","left","right"),this.view.classList.add(0===n?"bottom":"top"),this.view.classList.add(0===r?"left":"right"),this.view.classList.toggle("fixed",this.useFixedPosition);const h=U.BK(this.container);this.view.style.top=a-(this.useFixedPosition?U.BK(this.view).top:h.top)+"px",this.view.style.left=l-(this.useFixedPosition?U.BK(this.view).left:h.left)+"px",this.view.style.width="initial"}hide(e){const t=this.delegate;this.delegate=null,t?.onHide&&t.onHide(e),this.toDisposeOnClean.dispose(),U.jD(this.view)}isVisible(){return!!this.delegate}onDOMEvent(e,t){this.delegate&&(this.delegate.onDOMEvent?this.delegate.onDOMEvent(e,U.zk(e).document.activeElement):t&&!U.QX(e.target,this.container)&&this.hide())}dispose(){this.hide(),super.dispose()}}const it='\n\t:host {\n\t\tall: initial; /* 1st rule so subsequent properties are reset. */\n\t}\n\n\t.codicon[class*=\'codicon-\'] {\n\t\tfont: normal normal normal 16px/1 codicon;\n\t\tdisplay: inline-block;\n\t\ttext-decoration: none;\n\t\ttext-rendering: auto;\n\t\ttext-align: center;\n\t\t-webkit-font-smoothing: antialiased;\n\t\t-moz-osx-font-smoothing: grayscale;\n\t\tuser-select: none;\n\t\t-webkit-user-select: none;\n\t\t-ms-user-select: none;\n\t}\n\n\t:host {\n\t\tfont-family: -apple-system, BlinkMacSystemFont, "Segoe WPC", "Segoe UI", "HelveticaNeue-Light", system-ui, "Ubuntu", "Droid Sans", sans-serif;\n\t}\n\n\t:host-context(.mac) { font-family: -apple-system, BlinkMacSystemFont, sans-serif; }\n\t:host-context(.mac:lang(zh-Hans)) { font-family: -apple-system, BlinkMacSystemFont, "PingFang SC", "Hiragino Sans GB", sans-serif; }\n\t:host-context(.mac:lang(zh-Hant)) { font-family: -apple-system, BlinkMacSystemFont, "PingFang TC", sans-serif; }\n\t:host-context(.mac:lang(ja)) { font-family: -apple-system, BlinkMacSystemFont, "Hiragino Kaku Gothic Pro", sans-serif; }\n\t:host-context(.mac:lang(ko)) { font-family: -apple-system, BlinkMacSystemFont, "Nanum Gothic", "Apple SD Gothic Neo", "AppleGothic", sans-serif; }\n\n\t:host-context(.windows) { font-family: "Segoe WPC", "Segoe UI", sans-serif; }\n\t:host-context(.windows:lang(zh-Hans)) { font-family: "Segoe WPC", "Segoe UI", "Microsoft YaHei", sans-serif; }\n\t:host-context(.windows:lang(zh-Hant)) { font-family: "Segoe WPC", "Segoe UI", "Microsoft Jhenghei", sans-serif; }\n\t:host-context(.windows:lang(ja)) { font-family: "Segoe WPC", "Segoe UI", "Yu Gothic UI", "Meiryo UI", sans-serif; }\n\t:host-context(.windows:lang(ko)) { font-family: "Segoe WPC", "Segoe UI", "Malgun Gothic", "Dotom", sans-serif; }\n\n\t:host-context(.linux) { font-family: system-ui, "Ubuntu", "Droid Sans", sans-serif; }\n\t:host-context(.linux:lang(zh-Hans)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans SC", "Source Han Sans CN", "Source Han Sans", sans-serif; }\n\t:host-context(.linux:lang(zh-Hant)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans TC", "Source Han Sans TW", "Source Han Sans", sans-serif; }\n\t:host-context(.linux:lang(ja)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans J", "Source Han Sans JP", "Source Han Sans", sans-serif; }\n\t:host-context(.linux:lang(ko)) { font-family: system-ui, "Ubuntu", "Droid Sans", "Source Han Sans K", "Source Han Sans JR", "Source Han Sans", "UnDotum", "FBaekmuk Gulim", sans-serif; }\n';var st=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},nt=function(e,t){return function(i,s){t(i,s,e)}};let rt=class extends l.jG{constructor(e){super(),this.layoutService=e,this.contextView=this._register(new tt(this.layoutService.mainContainer,1)),this.layout(),this._register(e.onDidLayoutContainer((()=>this.layout())))}showContextView(e,t,i){let s;s=t?t===this.layoutService.getContainer((0,U.zk)(t))?1:i?3:2:1,this.contextView.setContainer(t??this.layoutService.activeContainer,s),this.contextView.show(e);const n={close:()=>{this.openContextView===n&&this.hideContextView()}};return this.openContextView=n,n}layout(){this.contextView.layout()}hideContextView(e){this.contextView.hide(e),this.openContextView=void 0}};rt=st([nt(0,le)],rt);class ot extends rt{getContextViewElement(){return this.contextView.getViewElement()}}var at=i(18447),lt=i(631);class ct{constructor(e,t,i){this.hoverDelegate=e,this.target=t,this.fadeInAnimation=i}async update(e,t,i){if(this._cancellationTokenSource&&(this._cancellationTokenSource.dispose(!0),this._cancellationTokenSource=void 0),this.isDisposed)return;let s;if(void 0===e||(0,lt.Kg)(e)||(0,U.sb)(e))s=e;else if((0,lt.Tn)(e.markdown)){this._hoverWidget||this.show((0,E.kg)("iconLabel.loading","Loading..."),t,i),this._cancellationTokenSource=new at.Qi;const n=this._cancellationTokenSource.token;if(s=await e.markdown(n),void 0===s&&(s=e.markdownNotSupportedFallback),this.isDisposed||n.isCancellationRequested)return}else s=e.markdown??e.markdownNotSupportedFallback;this.show(s,t,i)}show(e,t,i){const s=this._hoverWidget;if(this.hasContent(e)){const n={content:e,target:this.target,actions:i?.actions,linkHandler:i?.linkHandler,trapFocus:i?.trapFocus,appearance:{showPointer:"element"===this.hoverDelegate.placement,skipFadeInAnimation:!this.fadeInAnimation||!!s,showHoverHint:i?.appearance?.showHoverHint},position:{hoverPosition:2}};this._hoverWidget=this.hoverDelegate.showHover(n,t)}s?.dispose()}hasContent(e){return!!e&&(!(0,Be.VS)(e)||!!e.value)}get isDisposed(){return this._hoverWidget?.isDisposed}dispose(){this._hoverWidget?.dispose(),this._cancellationTokenSource?.dispose(!0),this._cancellationTokenSource=void 0}}var ht=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},dt=function(e,t){return function(i,s){t(i,s,e)}};let ut=class extends l.jG{constructor(e,t,i,s,n){super(),this._instantiationService=e,this._keybindingService=i,this._layoutService=s,this._accessibilityService=n,this._managedHovers=new Map,t.onDidShowContextMenu((()=>this.hideHover())),this._contextViewHandler=this._register(new rt(this._layoutService))}showHover(e,t,i){if(gt(this._currentHoverOptions)===gt(e))return;if(this._currentHover&&this._currentHoverOptions?.persistence?.sticky)return;this._currentHoverOptions=e,this._lastHoverOptions=e;const s=e.trapFocus||this._accessibilityService.isScreenReaderOptimized(),n=(0,U.bq)();i||(s&&n?n.classList.contains("monaco-hover")||(this._lastFocusedElementBeforeOpen=n):this._lastFocusedElementBeforeOpen=void 0);const r=new l.Cm,o=this._instantiationService.createInstance(Ye,e);if(e.persistence?.sticky&&(o.isLocked=!0),o.onDispose((()=>{this._currentHover?.domNode&&(0,U.nR)(this._currentHover.domNode)&&this._lastFocusedElementBeforeOpen?.focus(),this._currentHoverOptions===e&&(this._currentHoverOptions=void 0),r.dispose()}),void 0,r),!e.container){const t=(0,U.sb)(e.target)?e.target:e.target.targetElements[0];e.container=this._layoutService.getContainer((0,U.zk)(t))}if(this._contextViewHandler.showContextView(new pt(o,t),e.container),o.onRequestLayout((()=>this._contextViewHandler.layout()),void 0,r),e.persistence?.sticky)r.add((0,U.ko)((0,U.zk)(e.container).document,U.Bx.MOUSE_DOWN,(e=>{(0,U.QX)(e.target,o.domNode)||this.doHideHover()})));else{if("targetElements"in e.target)for(const i of e.target.targetElements)r.add((0,U.ko)(i,U.Bx.CLICK,(()=>this.hideHover())));else r.add((0,U.ko)(e.target,U.Bx.CLICK,(()=>this.hideHover())));const t=(0,U.bq)();if(t){const i=(0,U.zk)(t).document;r.add((0,U.ko)(t,U.Bx.KEY_DOWN,(t=>this._keyDown(t,o,!!e.persistence?.hideOnKeyDown)))),r.add((0,U.ko)(i,U.Bx.KEY_DOWN,(t=>this._keyDown(t,o,!!e.persistence?.hideOnKeyDown)))),r.add((0,U.ko)(t,U.Bx.KEY_UP,(e=>this._keyUp(e,o)))),r.add((0,U.ko)(i,U.Bx.KEY_UP,(e=>this._keyUp(e,o))))}}if("IntersectionObserver"in a.G){const t=new IntersectionObserver((e=>this._intersectionChange(e,o)),{threshold:0}),i="targetElements"in e.target?e.target.targetElements[0]:e.target;t.observe(i),r.add((0,l.s)((()=>t.disconnect())))}return this._currentHover=o,o}hideHover(){!this._currentHover?.isLocked&&this._currentHoverOptions&&this.doHideHover()}doHideHover(){this._currentHover=void 0,this._currentHoverOptions=void 0,this._contextViewHandler.hideContextView()}_intersectionChange(e,t){e[e.length-1].isIntersecting||t.dispose()}showAndFocusLastHover(){this._lastHoverOptions&&this.showHover(this._lastHoverOptions,!0,!0)}_keyDown(e,t,i){if("Alt"===e.key)return void(t.isLocked=!0);const s=new Xe.Z(e);this._keybindingService.resolveKeyboardEvent(s).getSingleModifierDispatchChords().some((e=>!!e))||0!==this._keybindingService.softDispatch(s,s.target).kind||!i||this._currentHoverOptions?.trapFocus&&"Tab"===e.key||(this.hideHover(),this._lastFocusedElementBeforeOpen?.focus())}_keyUp(e,t){"Alt"===e.key&&(t.isLocked=!1,t.isMouseIn||(this.hideHover(),this._lastFocusedElementBeforeOpen?.focus()))}setupManagedHover(e,t,i,s){let n,r;t.setAttribute("custom-hover","true"),""!==t.title&&(console.warn("HTML element already has a title attribute, which will conflict with the custom hover. Please remove the title attribute."),console.trace("Stack trace:",t.title),t.title="");const o=(t,i)=>{const s=void 0!==r;t&&(r?.dispose(),r=void 0),i&&(n?.dispose(),n=void 0),s&&(e.onDidHideHover?.(),r=void 0)},a=(n,o,a,l)=>new m.pc((async()=>{r&&!r.isDisposed||(r=new ct(e,a||t,n>0),await r.update("function"===typeof i?i():i,o,{...s,trapFocus:l}))}),n);let c=!1;const h=(0,U.ko)(t,U.Bx.MOUSE_DOWN,(()=>{c=!0,o(!0,!0)}),!0),d=(0,U.ko)(t,U.Bx.MOUSE_UP,(()=>{c=!1}),!0),u=(0,U.ko)(t,U.Bx.MOUSE_LEAVE,(e=>{c=!1,o(!1,e.fromElement===t)}),!0),g=(0,U.ko)(t,U.Bx.MOUSE_OVER,(i=>{if(n)return;const s=new l.Cm,r={targetElements:[t],dispose:()=>{}};if(void 0===e.placement||"mouse"===e.placement){const e=e=>{r.x=e.x+10,(0,U.sb)(e.target)&&mt(e.target,t)!==t&&o(!0,!0)};s.add((0,U.ko)(t,U.Bx.MOUSE_MOVE,e,!0))}n=s,(0,U.sb)(i.target)&&mt(i.target,t)!==t||s.add(a(e.delay,!1,r))}),!0),p=()=>{if(c||n)return;const i={targetElements:[t],dispose:()=>{}},s=new l.Cm;s.add((0,U.ko)(t,U.Bx.BLUR,(()=>o(!0,!0)),!0)),s.add(a(e.delay,!1,i)),n=s};let f;const _=t.tagName.toLowerCase();"input"!==_&&"textarea"!==_&&(f=(0,U.ko)(t,U.Bx.FOCUS,p,!0));const v={show:e=>{o(!1,!0),a(0,e,void 0,e)},hide:()=>{o(!0,!0)},update:async(e,t)=>{i=e,await(r?.update(i,void 0,t))},dispose:()=>{this._managedHovers.delete(t),g.dispose(),u.dispose(),h.dispose(),d.dispose(),f?.dispose(),o(!0,!0)}};return this._managedHovers.set(t,v),v}showManagedHover(e){const t=this._managedHovers.get(e);t&&t.show(!0)}dispose(){this._managedHovers.forEach((e=>e.dispose())),super.dispose()}};function gt(e){if(void 0!==e)return e?.id??e}ut=ht([dt(0,ae._Y),dt(1,Oe.Z),dt(2,De.b),dt(3,le),dt(4,Ve.j)],ut);class pt{get anchorPosition(){return this._hover.anchor}constructor(e,t=!1){this._hover=e,this._focus=t,this.layer=1}render(e){return this._hover.render(e),this._focus&&this._hover.focus(),this._hover}getAnchor(){return{x:this._hover.x,y:this._hover.y}}layout(){this._hover.layout()}}function mt(e,t){for(t=t??(0,U.zk)(e).document.body;!e.hasAttribute("custom-hover")&&e!==t;)e=e.parentElement;return e}(0,se.v)(Ie.TN,ut,1),(0,Z.zy)(((e,t)=>{const i=e.getColor(Ne.oZ8);i&&(t.addRule(`.monaco-workbench .workbench-hover .hover-row:not(:first-child):not(:empty) { border-top: 1px solid ${i.transparent(.5)}; }`),t.addRule(`.monaco-workbench .workbench-hover hr { border-top: 1px solid ${i.transparent(.5)}; }`))}));var ft=i(42539),_t=i(80537),vt=i(94371),Ct=i(7085),bt=i(83069),Et=i(18938),St=i(50091),yt=i(74320),wt=i(1646),Lt=i(46359);function Rt(e){return Object.isFrozen(e)?e:p.ol(e)}class Tt{static createEmptyModel(e){return new Tt({},[],[],void 0,e)}constructor(e,t,i,s,n){this._contents=e,this._keys=t,this._overrides=i,this.raw=s,this.logService=n,this.overrideConfigurations=new Map}get rawConfiguration(){if(!this._rawConfiguration)if(this.raw?.length){const e=this.raw.map((e=>{if(e instanceof Tt)return e;const t=new xt("",this.logService);return t.parseRaw(e),t.configurationModel}));this._rawConfiguration=e.reduce(((e,t)=>t===e?t:e.merge(t)),e[0])}else this._rawConfiguration=this;return this._rawConfiguration}get contents(){return this._contents}get overrides(){return this._overrides}get keys(){return this._keys}isEmpty(){return 0===this._keys.length&&0===Object.keys(this._contents).length&&0===this._overrides.length}getValue(e){return e?(0,Me.gD)(this.contents,e):this.contents}inspect(e,t){const i=this;return{get value(){return Rt(i.rawConfiguration.getValue(e))},get override(){return t?Rt(i.rawConfiguration.getOverrideValue(e,t)):void 0},get merged(){return Rt(t?i.rawConfiguration.override(t).getValue(e):i.rawConfiguration.getValue(e))},get overrides(){const t=[];for(const{contents:s,identifiers:n,keys:r}of i.rawConfiguration.overrides){const o=new Tt(s,r,[],void 0,i.logService).getValue(e);void 0!==o&&t.push({identifiers:n,value:o})}return t.length?Rt(t):void 0}}}getOverrideValue(e,t){const i=this.getContentsForOverrideIdentifer(t);return i?e?(0,Me.gD)(i,e):i:void 0}override(e){let t=this.overrideConfigurations.get(e);return t||(t=this.createOverrideConfigurationModel(e),this.overrideConfigurations.set(e,t)),t}merge(...e){const t=p.Go(this.contents),i=p.Go(this.overrides),s=[...this.keys],n=this.raw?.length?[...this.raw]:[this];for(const r of e)if(n.push(...r.raw?.length?r.raw:[r]),!r.isEmpty()){this.mergeContents(t,r.contents);for(const e of r.overrides){const[t]=i.filter((t=>b.aI(t.identifiers,e.identifiers)));t?(this.mergeContents(t.contents,e.contents),t.keys.push(...e.keys),t.keys=b.dM(t.keys)):i.push(p.Go(e))}for(const e of r.keys)-1===s.indexOf(e)&&s.push(e)}return new Tt(t,s,i,n.every((e=>e instanceof Tt))?void 0:n,this.logService)}createOverrideConfigurationModel(e){const t=this.getContentsForOverrideIdentifer(e);if(!t||"object"!==typeof t||!Object.keys(t).length)return this;const i={};for(const s of b.dM([...Object.keys(this.contents),...Object.keys(t)])){let e=this.contents[s];const n=t[s];n&&("object"===typeof e&&"object"===typeof n?(e=p.Go(e),this.mergeContents(e,n)):e=n),i[s]=e}return new Tt(i,this.keys,this.overrides,void 0,this.logService)}mergeContents(e,t){for(const i of Object.keys(t))i in e&<.Gv(e[i])&<.Gv(t[i])?this.mergeContents(e[i],t[i]):e[i]=p.Go(t[i])}getContentsForOverrideIdentifer(e){let t=null,i=null;const s=e=>{e&&(i?this.mergeContents(i,e):i=p.Go(e))};for(const n of this.overrides)1===n.identifiers.length&&n.identifiers[0]===e?t=n.contents:n.identifiers.includes(e)&&s(n.contents);return s(t),i}toJSON(){return{contents:this.contents,overrides:this.overrides,keys:this.keys}}setValue(e,t){this.updateValue(e,t,!1)}removeValue(e){const t=this.keys.indexOf(e);-1!==t&&(this.keys.splice(t,1),(0,Me.iB)(this.contents,e),wt.rC.test(e)&&this.overrides.splice(this.overrides.findIndex((t=>b.aI(t.identifiers,(0,wt.Gv)(e)))),1))}updateValue(e,t,i){if((0,Me.kW)(this.contents,e,t,(e=>this.logService.error(e))),(i=i||-1===this.keys.indexOf(e))&&this.keys.push(e),wt.rC.test(e)){const t=(0,wt.Gv)(e),i={identifiers:t,keys:Object.keys(this.contents[e]),contents:(0,Me.ad)(this.contents[e],(e=>this.logService.error(e)))},s=this.overrides.findIndex((e=>b.aI(e.identifiers,t)));-1!==s?this.overrides[s]=i:this.overrides.push(i)}}}class xt{constructor(e,t){this._name=e,this.logService=t,this._raw=null,this._configurationModel=null,this._restrictedConfigurations=[]}get configurationModel(){return this._configurationModel||Tt.createEmptyModel(this.logService)}parseRaw(e,t){this._raw=e;const{contents:i,keys:s,overrides:n,restricted:r,hasExcludedProperties:o}=this.doParseRaw(e,t);this._configurationModel=new Tt(i,s,n,o?[e]:void 0,this.logService),this._restrictedConfigurations=r||[]}doParseRaw(e,t){const i=Lt.O.as(wt.Fd.Configuration).getConfigurationProperties(),s=this.filter(e,i,!0,t);e=s.raw;return{contents:(0,Me.ad)(e,(e=>this.logService.error(`Conflict in settings file ${this._name}: ${e}`))),keys:Object.keys(e),overrides:this.toOverrides(e,(e=>this.logService.error(`Conflict in settings file ${this._name}: ${e}`))),restricted:s.restricted,hasExcludedProperties:s.hasExcludedProperties}}filter(e,t,i,s){let n=!1;if(!s?.scopes&&!s?.skipRestricted&&!s?.exclude?.length)return{raw:e,restricted:[],hasExcludedProperties:n};const r={},o=[];for(const a in e)if(wt.rC.test(a)&&i){const i=this.filter(e[a],t,!1,s);r[a]=i.raw,n=n||i.hasExcludedProperties,o.push(...i.restricted)}else{const i=t[a],l=i?"undefined"!==typeof i.scope?i.scope:3:void 0;i?.restricted&&o.push(a),s.exclude?.includes(a)||!s.include?.includes(a)&&(void 0!==l&&void 0!==s.scopes&&!s.scopes.includes(l)||s.skipRestricted&&i?.restricted)?n=!0:r[a]=e[a]}return{raw:r,restricted:o,hasExcludedProperties:n}}toOverrides(e,t){const i=[];for(const s of Object.keys(e))if(wt.rC.test(s)){const n={};for(const t in e[s])n[t]=e[s][t];i.push({identifiers:(0,wt.Gv)(s),keys:Object.keys(n),contents:(0,Me.ad)(n,t)})}return i}}class kt{constructor(e,t,i,s,n,r,o,a,l,c,h,d,u){this.key=e,this.overrides=t,this._value=i,this.overrideIdentifiers=s,this.defaultConfiguration=n,this.policyConfiguration=r,this.applicationConfiguration=o,this.userConfiguration=a,this.localUserConfiguration=l,this.remoteUserConfiguration=c,this.workspaceConfiguration=h,this.folderConfigurationModel=d,this.memoryConfigurationModel=u}toInspectValue(e){return void 0!==e?.value||void 0!==e?.override||void 0!==e?.overrides?e:void 0}get userInspectValue(){return this._userInspectValue||(this._userInspectValue=this.userConfiguration.inspect(this.key,this.overrides.overrideIdentifier)),this._userInspectValue}get user(){return this.toInspectValue(this.userInspectValue)}}class At{constructor(e,t,i,s,n,r,o,a,l,c){this._defaultConfiguration=e,this._policyConfiguration=t,this._applicationConfiguration=i,this._localUserConfiguration=s,this._remoteUserConfiguration=n,this._workspaceConfiguration=r,this._folderConfigurations=o,this._memoryConfiguration=a,this._memoryConfigurationByResource=l,this.logService=c,this._workspaceConsolidatedConfiguration=null,this._foldersConsolidatedConfigurations=new yt.fT,this._userConfiguration=null}getValue(e,t,i){return this.getConsolidatedConfigurationModel(e,t,i).getValue(e)}updateValue(e,t,i={}){let s;i.resource?(s=this._memoryConfigurationByResource.get(i.resource),s||(s=Tt.createEmptyModel(this.logService),this._memoryConfigurationByResource.set(i.resource,s))):s=this._memoryConfiguration,void 0===t?s.removeValue(e):s.setValue(e,t),i.resource||(this._workspaceConsolidatedConfiguration=null)}inspect(e,t,i){const s=this.getConsolidatedConfigurationModel(e,t,i),n=this.getFolderConfigurationModelForResource(t.resource,i),r=t.resource&&this._memoryConfigurationByResource.get(t.resource)||this._memoryConfiguration,o=new Set;for(const a of s.overrides)for(const t of a.identifiers)void 0!==s.getOverrideValue(e,t)&&o.add(t);return new kt(e,t,s.getValue(e),o.size?[...o]:void 0,this._defaultConfiguration,this._policyConfiguration.isEmpty()?void 0:this._policyConfiguration,this.applicationConfiguration.isEmpty()?void 0:this.applicationConfiguration,this.userConfiguration,this.localUserConfiguration,this.remoteUserConfiguration,i?this._workspaceConfiguration:void 0,n||void 0,r)}get applicationConfiguration(){return this._applicationConfiguration}get userConfiguration(){return this._userConfiguration||(this._userConfiguration=this._remoteUserConfiguration.isEmpty()?this._localUserConfiguration:this._localUserConfiguration.merge(this._remoteUserConfiguration)),this._userConfiguration}get localUserConfiguration(){return this._localUserConfiguration}get remoteUserConfiguration(){return this._remoteUserConfiguration}getConsolidatedConfigurationModel(e,t,i){let s=this.getConsolidatedConfigurationModelForResource(t,i);return t.overrideIdentifier&&(s=s.override(t.overrideIdentifier)),this._policyConfiguration.isEmpty()||void 0===this._policyConfiguration.getValue(e)||(s=s.merge(this._policyConfiguration)),s}getConsolidatedConfigurationModelForResource({resource:e},t){let i=this.getWorkspaceConsolidatedConfiguration();if(t&&e){const s=t.getFolder(e);s&&(i=this.getFolderConsolidatedConfiguration(s.uri)||i);const n=this._memoryConfigurationByResource.get(e);n&&(i=i.merge(n))}return i}getWorkspaceConsolidatedConfiguration(){return this._workspaceConsolidatedConfiguration||(this._workspaceConsolidatedConfiguration=this._defaultConfiguration.merge(this.applicationConfiguration,this.userConfiguration,this._workspaceConfiguration,this._memoryConfiguration)),this._workspaceConsolidatedConfiguration}getFolderConsolidatedConfiguration(e){let t=this._foldersConsolidatedConfigurations.get(e);if(!t){const i=this.getWorkspaceConsolidatedConfiguration(),s=this._folderConfigurations.get(e);s?(t=i.merge(s),this._foldersConsolidatedConfigurations.set(e,t)):t=i}return t}getFolderConfigurationModelForResource(e,t){if(t&&e){const i=t.getFolder(e);if(i)return this._folderConfigurations.get(i.uri)}}toData(){return{defaults:{contents:this._defaultConfiguration.contents,overrides:this._defaultConfiguration.overrides,keys:this._defaultConfiguration.keys},policy:{contents:this._policyConfiguration.contents,overrides:this._policyConfiguration.overrides,keys:this._policyConfiguration.keys},application:{contents:this.applicationConfiguration.contents,overrides:this.applicationConfiguration.overrides,keys:this.applicationConfiguration.keys},user:{contents:this.userConfiguration.contents,overrides:this.userConfiguration.overrides,keys:this.userConfiguration.keys},workspace:{contents:this._workspaceConfiguration.contents,overrides:this._workspaceConfiguration.overrides,keys:this._workspaceConfiguration.keys},folders:[...this._folderConfigurations.keys()].reduce(((e,t)=>{const{contents:i,overrides:s,keys:n}=this._folderConfigurations.get(t);return e.push([t,{contents:i,overrides:s,keys:n}]),e}),[])}}static parse(e,t){const i=this.parseConfigurationModel(e.defaults,t),s=this.parseConfigurationModel(e.policy,t),n=this.parseConfigurationModel(e.application,t),r=this.parseConfigurationModel(e.user,t),o=this.parseConfigurationModel(e.workspace,t),a=e.folders.reduce(((e,i)=>(e.set(h.r.revive(i[0]),this.parseConfigurationModel(i[1],t)),e)),new yt.fT);return new At(i,s,n,r,Tt.createEmptyModel(t),o,a,Tt.createEmptyModel(t),new yt.fT,t)}static parseConfigurationModel(e,t){return new Tt(e.contents,e.keys,e.overrides,void 0,t)}}class Nt{constructor(e,t,i,s,n){this.change=e,this.previous=t,this.currentConfiguraiton=i,this.currentWorkspace=s,this.logService=n,this._marker="\n",this._markerCode1=this._marker.charCodeAt(0),this._markerCode2=".".charCodeAt(0),this.affectedKeys=new Set,this._previousConfiguration=void 0;for(const r of e.keys)this.affectedKeys.add(r);for(const[,r]of e.overrides)for(const e of r)this.affectedKeys.add(e);this._affectsConfigStr=this._marker;for(const r of this.affectedKeys)this._affectsConfigStr+=r+this._marker}get previousConfiguration(){return!this._previousConfiguration&&this.previous&&(this._previousConfiguration=At.parse(this.previous.data,this.logService)),this._previousConfiguration}affectsConfiguration(e,t){const i=this._marker+e,s=this._affectsConfigStr.indexOf(i);if(s<0)return!1;const n=s+i.length;if(n>=this._affectsConfigStr.length)return!1;const r=this._affectsConfigStr.charCodeAt(n);if(r!==this._markerCode1&&r!==this._markerCode2)return!1;if(t){const i=this.previousConfiguration?this.previousConfiguration.getValue(e,t,this.previous?.workspace):void 0,s=this.currentConfiguraiton.getValue(e,t,this.currentWorkspace);return!p.aI(i,s)}return!0}}var It=i(2299);const Ot={kind:0},Dt={kind:1};class Mt{constructor(e,t,i){this._log=i,this._defaultKeybindings=e,this._defaultBoundCommands=new Map;for(const s of e){const e=s.command;e&&"-"!==e.charAt(0)&&this._defaultBoundCommands.set(e,!0)}this._map=new Map,this._lookupMap=new Map,this._keybindings=Mt.handleRemovals([].concat(e).concat(t));for(let s=0,n=this._keybindings.length;s=0;s--){const e=i[s];if(e.command===t.command)continue;let n=!0;for(let i=1;i=0;s--){const e=i[s];if(t.contextMatchesRules(e.when))return e}return i[i.length-1]}resolve(e,t,i){const s=[...t,i];this._log(`| Resolving ${s}`);const n=this._map.get(s[0]);if(void 0===n)return this._log("\\ No keybinding entries."),Ot;let r=null;if(s.length<2)r=n;else{r=[];for(let e=0,t=n.length;et.chords.length)continue;let i=!0;for(let e=1;e=0;i--){const s=t[i];if(Mt._contextMatchesRules(e,s.when))return s}return null}static _contextMatchesRules(e,t){return!t||t.evaluate(e)}}function Pt(e){return e?`${e.serialize()}`:"no when condition"}function Ft(e){return e.extensionId?e.isBuiltinExtension?`built-in extension ${e.extensionId}`:`user extension ${e.extensionId}`:e.isDefault?"built-in":"user"}const Ut=/^(cursor|delete|undo|redo|tab|editor\.action\.clipboard)/;class Ht extends l.jG{get onDidUpdateKeybindings(){return this._onDidUpdateKeybindings?this._onDidUpdateKeybindings.event:Q.Jh.None}get inChordMode(){return this._currentChords.length>0}constructor(e,t,i,s,n){super(),this._contextKeyService=e,this._commandService=t,this._telemetryService=i,this._notificationService=s,this._logService=n,this._onDidUpdateKeybindings=this._register(new Q.vl),this._currentChords=[],this._currentChordChecker=new m.vb,this._currentChordStatusMessage=null,this._ignoreSingleModifiers=Bt.EMPTY,this._currentSingleModifier=null,this._currentSingleModifierClearTimeout=new m.pc,this._currentlyDispatchingCommandId=null,this._logging=!1}dispose(){super.dispose()}_log(e){this._logging&&this._logService.info(`[KeybindingService]: ${e}`)}getKeybindings(){return this._getResolver().getKeybindings()}lookupKeybinding(e,t){const i=this._getResolver().lookupPrimaryKeybinding(e,t||this._contextKeyService);if(i)return i.resolvedKeybinding}dispatchEvent(e,t){return this._dispatch(e,t)}softDispatch(e,t){this._log("/ Soft dispatching keyboard event");const i=this.resolveKeyboardEvent(e);if(i.hasMultipleChords())return console.warn("keyboard event should not be mapped to multiple chords"),Ot;const[s]=i.getDispatchChords();if(null===s)return this._log("\\ Keyboard event cannot be dispatched"),Ot;const n=this._contextKeyService.getContext(t),r=this._currentChords.map((({keypress:e})=>e));return this._getResolver().resolve(n,r,s)}_scheduleLeaveChordMode(){const e=Date.now();this._currentChordChecker.cancelAndSet((()=>{this._documentHasFocus()?Date.now()-e>5e3&&this._leaveChordMode():this._leaveChordMode()}),500)}_expectAnotherChord(e,t){switch(this._currentChords.push({keypress:e,label:t}),this._currentChords.length){case 0:throw(0,v.iH)("impossible");case 1:this._currentChordStatusMessage=this._notificationService.status(E.kg("first.chord","({0}) was pressed. Waiting for second key of chord...",t));break;default:{const e=this._currentChords.map((({label:e})=>e)).join(", ");this._currentChordStatusMessage=this._notificationService.status(E.kg("next.chord","({0}) was pressed. Waiting for next key of chord...",e))}}this._scheduleLeaveChordMode(),It.M.enabled&&It.M.disable()}_leaveChordMode(){this._currentChordStatusMessage&&(this._currentChordStatusMessage.dispose(),this._currentChordStatusMessage=null),this._currentChordChecker.cancel(),this._currentChords=[],It.M.enable()}_dispatch(e,t){return this._doDispatch(this.resolveKeyboardEvent(e),t,!1)}_singleModifierDispatch(e,t){const i=this.resolveKeyboardEvent(e),[s]=i.getSingleModifierDispatchChords();if(s)return this._ignoreSingleModifiers.has(s)?(this._log(`+ Ignoring single modifier ${s} due to it being pressed together with other keys.`),this._ignoreSingleModifiers=Bt.EMPTY,this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,!1):(this._ignoreSingleModifiers=Bt.EMPTY,null===this._currentSingleModifier?(this._log(`+ Storing single modifier for possible chord ${s}.`),this._currentSingleModifier=s,this._currentSingleModifierClearTimeout.cancelAndSet((()=>{this._log("+ Clearing single modifier due to 300ms elapsed."),this._currentSingleModifier=null}),300),!1):s===this._currentSingleModifier?(this._log(`/ Dispatching single modifier chord ${s} ${s}`),this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,this._doDispatch(i,t,!0)):(this._log(`+ Clearing single modifier due to modifier mismatch: ${this._currentSingleModifier} ${s}`),this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,!1));const[n]=i.getChords();return this._ignoreSingleModifiers=new Bt(n),null!==this._currentSingleModifier&&this._log("+ Clearing single modifier due to other key up."),this._currentSingleModifierClearTimeout.cancel(),this._currentSingleModifier=null,!1}_doDispatch(e,t,i=!1){let s=!1;if(e.hasMultipleChords())return console.warn("Unexpected keyboard event mapped to multiple chords"),!1;let n=null,r=null;if(i){const[t]=e.getSingleModifierDispatchChords();n=t,r=t?[t]:[]}else[n]=e.getDispatchChords(),r=this._currentChords.map((({keypress:e})=>e));if(null===n)return this._log("\\ Keyboard event cannot be dispatched in keydown phase."),s;const o=this._contextKeyService.getContext(t),a=e.getLabel(),l=this._getResolver().resolve(o,r,n);switch(l.kind){case 0:if(this._logService.trace("KeybindingService#dispatch",a,"[ No matching keybinding ]"),this.inChordMode){const e=this._currentChords.map((({label:e})=>e)).join(", ");this._log(`+ Leaving multi-chord mode: Nothing bound to "${e}, ${a}".`),this._notificationService.status(E.kg("missing.chord","The key combination ({0}, {1}) is not a command.",e,a),{hideAfter:1e4}),this._leaveChordMode(),s=!0}return s;case 1:return this._logService.trace("KeybindingService#dispatch",a,"[ Several keybindings match - more chords needed ]"),s=!0,this._expectAnotherChord(n,a),this._log(1===this._currentChords.length?"+ Entering multi-chord mode...":"+ Continuing multi-chord mode..."),s;case 2:if(this._logService.trace("KeybindingService#dispatch",a,`[ Will dispatch command ${l.commandId} ]`),null===l.commandId||""===l.commandId){if(this.inChordMode){const e=this._currentChords.map((({label:e})=>e)).join(", ");this._log(`+ Leaving chord mode: Nothing bound to "${e}, ${a}".`),this._notificationService.status(E.kg("missing.chord","The key combination ({0}, {1}) is not a command.",e,a),{hideAfter:1e4}),this._leaveChordMode(),s=!0}}else{this.inChordMode&&this._leaveChordMode(),l.isBubble||(s=!0),this._log(`+ Invoking command ${l.commandId}.`),this._currentlyDispatchingCommandId=l.commandId;try{"undefined"===typeof l.commandArgs?this._commandService.executeCommand(l.commandId).then(void 0,(e=>this._notificationService.warn(e))):this._commandService.executeCommand(l.commandId,l.commandArgs).then(void 0,(e=>this._notificationService.warn(e)))}finally{this._currentlyDispatchingCommandId=null}Ut.test(l.commandId)||this._telemetryService.publicLog2("workbenchActionExecuted",{id:l.commandId,from:"keybinding",detail:e.getUserSettingsLabel()??void 0})}return s}}mightProducePrintableCharacter(e){return!e.ctrlKey&&!e.metaKey&&(e.keyCode>=31&&e.keyCode<=56||e.keyCode>=21&&e.keyCode<=30)}}class Bt{static{this.EMPTY=new Bt(null)}constructor(e){this._ctrlKey=!!e&&e.ctrlKey,this._shiftKey=!!e&&e.shiftKey,this._altKey=!!e&&e.altKey,this._metaKey=!!e&&e.metaKey}has(e){switch(e){case"ctrl":return this._ctrlKey;case"shift":return this._shiftKey;case"alt":return this._altKey;case"meta":return this._metaKey}}}var Wt=i(59261);class Vt{constructor(e,t,i,s,n,r,o){this._resolvedKeybindingItemBrand=void 0,this.resolvedKeybinding=e,this.chords=e?zt(e.getDispatchChords()):[],e&&0===this.chords.length&&(this.chords=zt(e.getSingleModifierDispatchChords())),this.bubble=!!t&&94===t.charCodeAt(0),this.command=this.bubble?t.substr(1):t,this.commandArgs=i,this.when=s,this.isDefault=n,this.extensionId=r,this.isBuiltinExtension=o}}function zt(e){const t=[];for(let i=0,s=e.length;ithis._getLabel(e)))}getAriaLabel(){return jt.r0.toLabel(this._os,this._chords,(e=>this._getAriaLabel(e)))}getElectronAccelerator(){return this._chords.length>1||this._chords[0].isDuplicateModifierCase()?null:jt.rr.toLabel(this._os,this._chords,(e=>this._getElectronAccelerator(e)))}getUserSettingsLabel(){return jt.G$.toLabel(this._os,this._chords,(e=>this._getUserSettingsLabel(e)))}hasMultipleChords(){return this._chords.length>1}getChords(){return this._chords.map((e=>this._getChord(e)))}_getChord(e){return new ft.FW(e.ctrlKey,e.shiftKey,e.altKey,e.metaKey,this._getLabel(e),this._getAriaLabel(e))}getDispatchChords(){return this._chords.map((e=>this._getChordDispatch(e)))}getSingleModifierDispatchChords(){return this._chords.map((e=>this._getSingleModifierChordDispatch(e)))}}class Yt extends Kt{constructor(e,t){super(t,e)}_keyCodeToUILabel(e){if(2===this._os)switch(e){case 15:return"\u2190";case 16:return"\u2191";case 17:return"\u2192";case 18:return"\u2193"}return Gt.YM.toString(e)}_getLabel(e){return e.isDuplicateModifierCase()?"":this._keyCodeToUILabel(e.keyCode)}_getAriaLabel(e){return e.isDuplicateModifierCase()?"":Gt.YM.toString(e.keyCode)}_getElectronAccelerator(e){return Gt.YM.toElectronAccelerator(e.keyCode)}_getUserSettingsLabel(e){if(e.isDuplicateModifierCase())return"";const t=Gt.YM.toUserSettingsUS(e.keyCode);return t?t.toLowerCase():t}_getChordDispatch(e){return Yt.getDispatchStr(e)}static getDispatchStr(e){if(e.isModifierKey())return null;let t="";return e.ctrlKey&&(t+="ctrl+"),e.shiftKey&&(t+="shift+"),e.altKey&&(t+="alt+"),e.metaKey&&(t+="meta+"),t+=Gt.YM.toString(e.keyCode),t}_getSingleModifierChordDispatch(e){return 5!==e.keyCode||e.shiftKey||e.altKey||e.metaKey?4!==e.keyCode||e.ctrlKey||e.altKey||e.metaKey?6!==e.keyCode||e.ctrlKey||e.shiftKey||e.metaKey?57!==e.keyCode||e.ctrlKey||e.shiftKey||e.altKey?null:"meta":"alt":"shift":"ctrl"}static _scanCodeToKeyCode(e){const t=Gt.Fo[e];if(-1!==t)return t;switch(e){case 10:return 31;case 11:return 32;case 12:return 33;case 13:return 34;case 14:return 35;case 15:return 36;case 16:return 37;case 17:return 38;case 18:return 39;case 19:return 40;case 20:return 41;case 21:return 42;case 22:return 43;case 23:return 44;case 24:return 45;case 25:return 46;case 26:return 47;case 27:return 48;case 28:return 49;case 29:return 50;case 30:return 51;case 31:return 52;case 32:return 53;case 33:return 54;case 34:return 55;case 35:return 56;case 36:return 22;case 37:return 23;case 38:return 24;case 39:return 25;case 40:return 26;case 41:return 27;case 42:return 28;case 43:return 29;case 44:return 30;case 45:return 21;case 51:return 88;case 52:return 86;case 53:return 92;case 54:return 94;case 55:return 93;case 56:return 0;case 57:return 85;case 58:return 95;case 59:return 91;case 60:return 87;case 61:return 89;case 62:return 90;case 106:return 97}return 0}static _toKeyCodeChord(e){if(!e)return null;if(e instanceof ft.dG)return e;const t=this._scanCodeToKeyCode(e.scanCode);return 0===t?null:new ft.dG(e.ctrlKey,e.shiftKey,e.altKey,e.metaKey,t)}static resolveKeybinding(e,t){const i=zt(e.chords.map((e=>this._toKeyCodeChord(e))));return i.length>0?[new Yt(i,t)]:[]}}var qt=i(67841),$t=i(73823),Qt=i(90651),Xt=i(37227),Zt=i(51861),Jt=i(89403),ei=i(51465),ti=i(17890),ii=i(36921),si=i(57629),ni=i(27195),ri=i(47358),oi=i(60413),ai=i(25154),li=i(11799),ci=i(5646),hi=i(31295),di=i(10350),ui=i(18956),gi=i(25689),pi=i(37882);const mi=/\(&([^\s&])\)|(^|[^&])&([^\s&])/,fi=/(&)?(&)([^\s&])/g;var _i,vi;!function(e){e[e.Right=0]="Right",e[e.Left=1]="Left"}(_i||(_i={})),function(e){e[e.Above=0]="Above",e[e.Below=1]="Below"}(vi||(vi={}));class Ci extends li.E{constructor(e,t,i,s){e.classList.add("monaco-menu-container"),e.setAttribute("role","presentation");const n=document.createElement("div");n.classList.add("monaco-menu"),n.setAttribute("role","presentation"),super(n,{orientation:1,actionViewItemProvider:e=>this.doGetActionViewItem(e,i,r),context:i.context,actionRunner:i.actionRunner,ariaLabel:i.ariaLabel,ariaRole:"menu",focusOnlyEnabledItems:!0,triggerKeys:{keys:[3,...We.zx||We.j9?[10]:[]],keyDown:!0}}),this.menuStyles=s,this.menuElement=n,this.actionsList.tabIndex=0,this.initializeOrUpdateStyleSheet(e,s),this._register(ai.q.addTarget(n)),this._register((0,U.ko)(n,U.Bx.KEY_DOWN,(e=>{new Xe.Z(e).equals(2)&&e.preventDefault()}))),i.enableMnemonics&&this._register((0,U.ko)(n,U.Bx.KEY_DOWN,(e=>{const t=e.key.toLocaleLowerCase();if(this.mnemonics.has(t)){U.fs.stop(e,!0);const i=this.mnemonics.get(t);if(1===i.length&&(i[0]instanceof Ei&&i[0].container&&this.focusItemByElement(i[0].container),i[0].onClick(e)),i.length>1){const e=i.shift();e&&e.container&&(this.focusItemByElement(e.container),i.push(e)),this.mnemonics.set(t,i)}}}))),We.j9&&this._register((0,U.ko)(n,U.Bx.KEY_DOWN,(e=>{const t=new Xe.Z(e);t.equals(14)||t.equals(11)?(this.focusedItem=this.viewItems.length-1,this.focusNext(),U.fs.stop(e,!0)):(t.equals(13)||t.equals(12))&&(this.focusedItem=0,this.focusPrevious(),U.fs.stop(e,!0))}))),this._register((0,U.ko)(this.domNode,U.Bx.MOUSE_OUT,(e=>{const t=e.relatedTarget;(0,U.QX)(t,this.domNode)||(this.focusedItem=void 0,this.updateFocus(),e.stopPropagation())}))),this._register((0,U.ko)(this.actionsList,U.Bx.MOUSE_OVER,(e=>{let t=e.target;if(t&&(0,U.QX)(t,this.actionsList)&&t!==this.actionsList){for(;t.parentElement!==this.actionsList&&null!==t.parentElement;)t=t.parentElement;if(t.classList.contains("action-item")){const e=this.focusedItem;this.setFocusedItem(t),e!==this.focusedItem&&this.updateFocus()}}}))),this._register(ai.q.addTarget(this.actionsList)),this._register((0,U.ko)(this.actionsList,ai.B.Tap,(e=>{let t=e.initialTarget;if(t&&(0,U.QX)(t,this.actionsList)&&t!==this.actionsList){for(;t.parentElement!==this.actionsList&&null!==t.parentElement;)t=t.parentElement;if(t.classList.contains("action-item")){const e=this.focusedItem;this.setFocusedItem(t),e!==this.focusedItem&&this.updateFocus()}}})));const r={parent:this};this.mnemonics=new Map,this.scrollableElement=this._register(new hi.MU(n,{alwaysConsumeMouseWheel:!0,horizontal:2,vertical:3,verticalScrollbarSize:7,handleMouseWheel:!0,useShadows:!0}));const o=this.scrollableElement.getDomNode();o.style.position="",this.styleScrollElement(o,s),this._register((0,U.ko)(n,ai.B.Change,(e=>{U.fs.stop(e,!0);const t=this.scrollableElement.getScrollPosition().scrollTop;this.scrollableElement.setScrollPosition({scrollTop:t-e.translationY})}))),this._register((0,U.ko)(o,U.Bx.MOUSE_UP,(e=>{e.preventDefault()})));const a=(0,U.zk)(e);n.style.maxHeight=`${Math.max(10,a.innerHeight-e.getBoundingClientRect().top-35)}px`,t=t.filter(((e,s)=>{if(i.submenuIds?.has(e.id))return console.warn(`Found submenu cycle: ${e.id}`),!1;if(e instanceof ii.wv){if(s===t.length-1||0===s)return!1;if(t[s-1]instanceof ii.wv)return!1}return!0})),this.push(t,{icon:!0,label:!0,isMenu:!0}),e.appendChild(this.scrollableElement.getDomNode()),this.scrollableElement.scanDomNode(),this.viewItems.filter((e=>!(e instanceof Si))).forEach(((e,t,i)=>{e.updatePositionInSet(t+1,i.length)}))}initializeOrUpdateStyleSheet(e,t){this.styleSheet||((0,U.Cl)(e)?this.styleSheet=(0,U.li)(e):(Ci.globalStyleSheet||(Ci.globalStyleSheet=(0,U.li)()),this.styleSheet=Ci.globalStyleSheet)),this.styleSheet.textContent=function(e,t){let i=`\n.monaco-menu {\n\tfont-size: 13px;\n\tborder-radius: 5px;\n\tmin-width: 160px;\n}\n\n${yi(di.W.menuSelection)}\n${yi(di.W.menuSubmenu)}\n\n.monaco-menu .monaco-action-bar {\n\ttext-align: right;\n\toverflow: hidden;\n\twhite-space: nowrap;\n}\n\n.monaco-menu .monaco-action-bar .actions-container {\n\tdisplay: flex;\n\tmargin: 0 auto;\n\tpadding: 0;\n\twidth: 100%;\n\tjustify-content: flex-end;\n}\n\n.monaco-menu .monaco-action-bar.vertical .actions-container {\n\tdisplay: inline-block;\n}\n\n.monaco-menu .monaco-action-bar.reverse .actions-container {\n\tflex-direction: row-reverse;\n}\n\n.monaco-menu .monaco-action-bar .action-item {\n\tcursor: pointer;\n\tdisplay: inline-block;\n\ttransition: transform 50ms ease;\n\tposition: relative; /* DO NOT REMOVE - this is the key to preventing the ghosting icon bug in Chrome 42 */\n}\n\n.monaco-menu .monaco-action-bar .action-item.disabled {\n\tcursor: default;\n}\n\n.monaco-menu .monaco-action-bar .action-item .icon,\n.monaco-menu .monaco-action-bar .action-item .codicon {\n\tdisplay: inline-block;\n}\n\n.monaco-menu .monaco-action-bar .action-item .codicon {\n\tdisplay: flex;\n\talign-items: center;\n}\n\n.monaco-menu .monaco-action-bar .action-label {\n\tfont-size: 11px;\n\tmargin-right: 4px;\n}\n\n.monaco-menu .monaco-action-bar .action-item.disabled .action-label,\n.monaco-menu .monaco-action-bar .action-item.disabled .action-label:hover {\n\tcolor: var(--vscode-disabledForeground);\n}\n\n/* Vertical actions */\n\n.monaco-menu .monaco-action-bar.vertical {\n\ttext-align: left;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item {\n\tdisplay: block;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\tdisplay: block;\n\tborder-bottom: 1px solid var(--vscode-menu-separatorBackground);\n\tpadding-top: 1px;\n\tpadding: 30px;\n}\n\n.monaco-menu .secondary-actions .monaco-action-bar .action-label {\n\tmargin-left: 6px;\n}\n\n/* Action Items */\n.monaco-menu .monaco-action-bar .action-item.select-container {\n\toverflow: hidden; /* somehow the dropdown overflows its container, we prevent it here to not push */\n\tflex: 1;\n\tmax-width: 170px;\n\tmin-width: 60px;\n\tdisplay: flex;\n\talign-items: center;\n\tjustify-content: center;\n\tmargin-right: 10px;\n}\n\n.monaco-menu .monaco-action-bar.vertical {\n\tmargin-left: 0;\n\toverflow: visible;\n}\n\n.monaco-menu .monaco-action-bar.vertical .actions-container {\n\tdisplay: block;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item {\n\tpadding: 0;\n\ttransform: none;\n\tdisplay: flex;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item.active {\n\ttransform: none;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item {\n\tflex: 1 1 auto;\n\tdisplay: flex;\n\theight: 2em;\n\talign-items: center;\n\tposition: relative;\n\tmargin: 0 4px;\n\tborder-radius: 4px;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item:hover .keybinding,\n.monaco-menu .monaco-action-bar.vertical .action-menu-item:focus .keybinding {\n\topacity: unset;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label {\n\tflex: 1 1 auto;\n\ttext-decoration: none;\n\tpadding: 0 1em;\n\tbackground: none;\n\tfont-size: 12px;\n\tline-height: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .keybinding,\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\tdisplay: inline-block;\n\tflex: 2 1 auto;\n\tpadding: 0 1em;\n\ttext-align: right;\n\tfont-size: 12px;\n\tline-height: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\theight: 100%;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator.codicon {\n\tfont-size: 16px !important;\n\tdisplay: flex;\n\talign-items: center;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator.codicon::before {\n\tmargin-left: auto;\n\tmargin-right: -20px;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item.disabled .keybinding,\n.monaco-menu .monaco-action-bar.vertical .action-item.disabled .submenu-indicator {\n\topacity: 0.4;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label:not(.separator) {\n\tdisplay: inline-block;\n\tbox-sizing: border-box;\n\tmargin: 0;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item {\n\tposition: static;\n\toverflow: visible;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-item .monaco-submenu {\n\tposition: absolute;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\twidth: 100%;\n\theight: 0px !important;\n\topacity: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator.text {\n\tpadding: 0.7em 1em 0.1em 1em;\n\tfont-weight: bold;\n\topacity: 1;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label:hover {\n\tcolor: inherit;\n}\n\n.monaco-menu .monaco-action-bar.vertical .menu-item-check {\n\tposition: absolute;\n\tvisibility: hidden;\n\twidth: 1em;\n\theight: 100%;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item.checked .menu-item-check {\n\tvisibility: visible;\n\tdisplay: flex;\n\talign-items: center;\n\tjustify-content: center;\n}\n\n/* Context Menu */\n\n.context-view.monaco-menu-container {\n\toutline: 0;\n\tborder: none;\n\tanimation: fadeIn 0.083s linear;\n\t-webkit-app-region: no-drag;\n}\n\n.context-view.monaco-menu-container :focus,\n.context-view.monaco-menu-container .monaco-action-bar.vertical:focus,\n.context-view.monaco-menu-container .monaco-action-bar.vertical :focus {\n\toutline: 0;\n}\n\n.hc-black .context-view.monaco-menu-container,\n.hc-light .context-view.monaco-menu-container,\n:host-context(.hc-black) .context-view.monaco-menu-container,\n:host-context(.hc-light) .context-view.monaco-menu-container {\n\tbox-shadow: none;\n}\n\n.hc-black .monaco-menu .monaco-action-bar.vertical .action-item.focused,\n.hc-light .monaco-menu .monaco-action-bar.vertical .action-item.focused,\n:host-context(.hc-black) .monaco-menu .monaco-action-bar.vertical .action-item.focused,\n:host-context(.hc-light) .monaco-menu .monaco-action-bar.vertical .action-item.focused {\n\tbackground: none;\n}\n\n/* Vertical Action Bar Styles */\n\n.monaco-menu .monaco-action-bar.vertical {\n\tpadding: 4px 0;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-menu-item {\n\theight: 2em;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label:not(.separator),\n.monaco-menu .monaco-action-bar.vertical .keybinding {\n\tfont-size: inherit;\n\tpadding: 0 2em;\n\tmax-height: 100%;\n}\n\n.monaco-menu .monaco-action-bar.vertical .menu-item-check {\n\tfont-size: inherit;\n\twidth: 2em;\n}\n\n.monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\tfont-size: inherit;\n\tmargin: 5px 0 !important;\n\tpadding: 0;\n\tborder-radius: 0;\n}\n\n.linux .monaco-menu .monaco-action-bar.vertical .action-label.separator,\n:host-context(.linux) .monaco-menu .monaco-action-bar.vertical .action-label.separator {\n\tmargin-left: 0;\n\tmargin-right: 0;\n}\n\n.monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\tfont-size: 60%;\n\tpadding: 0 1.8em;\n}\n\n.linux .monaco-menu .monaco-action-bar.vertical .submenu-indicator,\n:host-context(.linux) .monaco-menu .monaco-action-bar.vertical .submenu-indicator {\n\theight: 100%;\n\tmask-size: 10px 10px;\n\t-webkit-mask-size: 10px 10px;\n}\n\n.monaco-menu .action-item {\n\tcursor: default;\n}`;if(t){i+="\n\t\t\t/* Arrows */\n\t\t\t.monaco-scrollable-element > .scrollbar > .scra {\n\t\t\t\tcursor: pointer;\n\t\t\t\tfont-size: 11px !important;\n\t\t\t}\n\n\t\t\t.monaco-scrollable-element > .visible {\n\t\t\t\topacity: 1;\n\n\t\t\t\t/* Background rule added for IE9 - to allow clicks on dom node */\n\t\t\t\tbackground:rgba(0,0,0,0);\n\n\t\t\t\ttransition: opacity 100ms linear;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .invisible {\n\t\t\t\topacity: 0;\n\t\t\t\tpointer-events: none;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .invisible.fade {\n\t\t\t\ttransition: opacity 800ms linear;\n\t\t\t}\n\n\t\t\t/* Scrollable Content Inset Shadow */\n\t\t\t.monaco-scrollable-element > .shadow {\n\t\t\t\tposition: absolute;\n\t\t\t\tdisplay: none;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .shadow.top {\n\t\t\t\tdisplay: block;\n\t\t\t\ttop: 0;\n\t\t\t\tleft: 3px;\n\t\t\t\theight: 3px;\n\t\t\t\twidth: 100%;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .shadow.left {\n\t\t\t\tdisplay: block;\n\t\t\t\ttop: 3px;\n\t\t\t\tleft: 0;\n\t\t\t\theight: 100%;\n\t\t\t\twidth: 3px;\n\t\t\t}\n\t\t\t.monaco-scrollable-element > .shadow.top-left-corner {\n\t\t\t\tdisplay: block;\n\t\t\t\ttop: 0;\n\t\t\t\tleft: 0;\n\t\t\t\theight: 3px;\n\t\t\t\twidth: 3px;\n\t\t\t}\n\t\t";const t=e.scrollbarShadow;t&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .shadow.top {\n\t\t\t\t\tbox-shadow: ${t} 0 6px 6px -6px inset;\n\t\t\t\t}\n\n\t\t\t\t.monaco-scrollable-element > .shadow.left {\n\t\t\t\t\tbox-shadow: ${t} 6px 0 6px -6px inset;\n\t\t\t\t}\n\n\t\t\t\t.monaco-scrollable-element > .shadow.top.left {\n\t\t\t\t\tbox-shadow: ${t} 6px 6px 6px -6px inset;\n\t\t\t\t}\n\t\t\t`);const s=e.scrollbarSliderBackground;s&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .scrollbar > .slider {\n\t\t\t\t\tbackground: ${s};\n\t\t\t\t}\n\t\t\t`);const n=e.scrollbarSliderHoverBackground;n&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .scrollbar > .slider:hover {\n\t\t\t\t\tbackground: ${n};\n\t\t\t\t}\n\t\t\t`);const r=e.scrollbarSliderActiveBackground;r&&(i+=`\n\t\t\t\t.monaco-scrollable-element > .scrollbar > .slider.active {\n\t\t\t\t\tbackground: ${r};\n\t\t\t\t}\n\t\t\t`)}return i}(t,(0,U.Cl)(e))}styleScrollElement(e,t){const i=t.foregroundColor??"",s=t.backgroundColor??"",n=t.borderColor?`1px solid ${t.borderColor}`:"",r=t.shadowColor?`0 2px 8px ${t.shadowColor}`:"";e.style.outline=n,e.style.borderRadius="5px",e.style.color=i,e.style.backgroundColor=s,e.style.boxShadow=r}getContainer(){return this.scrollableElement.getDomNode()}get onScroll(){return this.scrollableElement.onScroll}focusItemByElement(e){const t=this.focusedItem;this.setFocusedItem(e),t!==this.focusedItem&&this.updateFocus()}setFocusedItem(e){for(let t=0;t{this.element&&(this._register((0,U.ko)(this.element,U.Bx.MOUSE_UP,(e=>{if(U.fs.stop(e,!0),oi.gm){if(new ri.P((0,U.zk)(this.element),e).rightButton)return;this.onClick(e)}else setTimeout((()=>{this.onClick(e)}),0)}))),this._register((0,U.ko)(this.element,U.Bx.CONTEXT_MENU,(e=>{U.fs.stop(e,!0)}))))}),100),this._register(this.runOnceToEnableMouseUp)}render(e){super.render(e),this.element&&(this.container=e,this.item=(0,U.BC)(this.element,(0,U.$)("a.action-menu-item")),this._action.id===ii.wv.ID?this.item.setAttribute("role","presentation"):(this.item.setAttribute("role","menuitem"),this.mnemonic&&this.item.setAttribute("aria-keyshortcuts",`${this.mnemonic}`)),this.check=(0,U.BC)(this.item,(0,U.$)("span.menu-item-check"+gi.L.asCSSSelector(di.W.menuSelection))),this.check.setAttribute("role","none"),this.label=(0,U.BC)(this.item,(0,U.$)("span.action-label")),this.options.label&&this.options.keybinding&&((0,U.BC)(this.item,(0,U.$)("span.keybinding")).textContent=this.options.keybinding),this.runOnceToEnableMouseUp.schedule(),this.updateClass(),this.updateLabel(),this.updateTooltip(),this.updateEnabled(),this.updateChecked(),this.applyStyle())}blur(){super.blur(),this.applyStyle()}focus(){super.focus(),this.item?.focus(),this.applyStyle()}updatePositionInSet(e,t){this.item&&(this.item.setAttribute("aria-posinset",`${e}`),this.item.setAttribute("aria-setsize",`${t}`))}updateLabel(){if(this.label&&this.options.label){(0,U.w_)(this.label);let e=(0,pi.pS)(this.action.label);if(e){const t=function(e){const t=mi,i=t.exec(e);if(!i)return e;const s=!i[1];return e.replace(t,s?"$2$3":"").trim()}(e);this.options.enableMnemonics||(e=t),this.label.setAttribute("aria-label",t.replace(/&&/g,"&"));const i=mi.exec(e);if(i){e=c.ih(e),fi.lastIndex=0;let t=fi.exec(e);for(;t&&t[1];)t=fi.exec(e);const s=e=>e.replace(/&&/g,"&");t?this.label.append(c.NB(s(e.substr(0,t.index))," "),(0,U.$)("u",{"aria-hidden":"true"},t[3]),c.BO(s(e.substr(t.index+t[0].length))," ")):this.label.innerText=s(e).trim(),this.item?.setAttribute("aria-keyshortcuts",(i[1]?i[1]:i[3]).toLocaleLowerCase())}else this.label.innerText=e.replace(/&&/g,"&").trim()}}}updateTooltip(){}updateClass(){this.cssClass&&this.item&&this.item.classList.remove(...this.cssClass.split(" ")),this.options.icon&&this.label?(this.cssClass=this.action.class||"",this.label.classList.add("icon"),this.cssClass&&this.label.classList.add(...this.cssClass.split(" ")),this.updateEnabled()):this.label&&this.label.classList.remove("icon")}updateEnabled(){this.action.enabled?(this.element&&(this.element.classList.remove("disabled"),this.element.removeAttribute("aria-disabled")),this.item&&(this.item.classList.remove("disabled"),this.item.removeAttribute("aria-disabled"),this.item.tabIndex=0)):(this.element&&(this.element.classList.add("disabled"),this.element.setAttribute("aria-disabled","true")),this.item&&(this.item.classList.add("disabled"),this.item.setAttribute("aria-disabled","true")))}updateChecked(){if(!this.item)return;const e=this.action.checked;this.item.classList.toggle("checked",!!e),void 0!==e?(this.item.setAttribute("role","menuitemcheckbox"),this.item.setAttribute("aria-checked",e?"true":"false")):(this.item.setAttribute("role","menuitem"),this.item.setAttribute("aria-checked",""))}getMnemonic(){return this.mnemonic}applyStyle(){const e=this.element&&this.element.classList.contains("focused"),t=e&&this.menuStyle.selectionForegroundColor?this.menuStyle.selectionForegroundColor:this.menuStyle.foregroundColor,i=e&&this.menuStyle.selectionBackgroundColor?this.menuStyle.selectionBackgroundColor:void 0,s=e&&this.menuStyle.selectionBorderColor?`1px solid ${this.menuStyle.selectionBorderColor}`:"",n=e&&this.menuStyle.selectionBorderColor?"-1px":"";this.item&&(this.item.style.color=t??"",this.item.style.backgroundColor=i??"",this.item.style.outline=s,this.item.style.outlineOffset=n),this.check&&(this.check.style.color=t??"")}}class Ei extends bi{constructor(e,t,i,s,n){super(e,e,s,n),this.submenuActions=t,this.parentData=i,this.submenuOptions=s,this.mysubmenu=null,this.submenuDisposables=this._register(new l.Cm),this.mouseOver=!1,this.expandDirection=s&&void 0!==s.expandDirection?s.expandDirection:{horizontal:_i.Right,vertical:vi.Below},this.showScheduler=new m.uC((()=>{this.mouseOver&&(this.cleanupExistingSubmenu(!1),this.createSubmenu(!1))}),250),this.hideScheduler=new m.uC((()=>{this.element&&!(0,U.QX)((0,U.bq)(),this.element)&&this.parentData.submenu===this.mysubmenu&&(this.parentData.parent.focus(!1),this.cleanupExistingSubmenu(!0))}),750)}render(e){super.render(e),this.element&&(this.item&&(this.item.classList.add("monaco-submenu-item"),this.item.tabIndex=0,this.item.setAttribute("aria-haspopup","true"),this.updateAriaExpanded("false"),this.submenuIndicator=(0,U.BC)(this.item,(0,U.$)("span.submenu-indicator"+gi.L.asCSSSelector(di.W.menuSubmenu))),this.submenuIndicator.setAttribute("aria-hidden","true")),this._register((0,U.ko)(this.element,U.Bx.KEY_UP,(e=>{const t=new Xe.Z(e);(t.equals(17)||t.equals(3))&&(U.fs.stop(e,!0),this.createSubmenu(!0))}))),this._register((0,U.ko)(this.element,U.Bx.KEY_DOWN,(e=>{const t=new Xe.Z(e);(0,U.bq)()===this.item&&(t.equals(17)||t.equals(3))&&U.fs.stop(e,!0)}))),this._register((0,U.ko)(this.element,U.Bx.MOUSE_OVER,(e=>{this.mouseOver||(this.mouseOver=!0,this.showScheduler.schedule())}))),this._register((0,U.ko)(this.element,U.Bx.MOUSE_LEAVE,(e=>{this.mouseOver=!1}))),this._register((0,U.ko)(this.element,U.Bx.FOCUS_OUT,(e=>{this.element&&!(0,U.QX)((0,U.bq)(),this.element)&&this.hideScheduler.schedule()}))),this._register(this.parentData.parent.onScroll((()=>{this.parentData.submenu===this.mysubmenu&&(this.parentData.parent.focus(!1),this.cleanupExistingSubmenu(!0))}))))}updateEnabled(){}onClick(e){U.fs.stop(e,!0),this.cleanupExistingSubmenu(!1),this.createSubmenu(!0)}cleanupExistingSubmenu(e){if(this.parentData.submenu&&(e||this.parentData.submenu!==this.mysubmenu)){try{this.parentData.submenu.dispose()}catch{}this.parentData.submenu=void 0,this.updateAriaExpanded("false"),this.submenuContainer&&(this.submenuDisposables.clear(),this.submenuContainer=void 0)}}calculateSubmenuMenuLayout(e,t,i,s){const n={top:0,left:0};return n.left=et(e.width,t.width,{position:s.horizontal===_i.Right?0:1,offset:i.left,size:i.width}),n.left>=i.left&&n.left{new Xe.Z(e).equals(15)&&(U.fs.stop(e,!0),this.parentData.parent.focus(),this.cleanupExistingSubmenu(!0))}))),this.submenuDisposables.add((0,U.ko)(this.submenuContainer,U.Bx.KEY_DOWN,(e=>{new Xe.Z(e).equals(15)&&U.fs.stop(e,!0)}))),this.submenuDisposables.add(this.parentData.submenu.onDidCancel((()=>{this.parentData.parent.focus(),this.cleanupExistingSubmenu(!0)}))),this.parentData.submenu.focus(e),this.mysubmenu=this.parentData.submenu}}updateAriaExpanded(e){this.item&&this.item?.setAttribute("aria-expanded",e)}applyStyle(){super.applyStyle();const e=this.element&&this.element.classList.contains("focused")&&this.menuStyle.selectionForegroundColor?this.menuStyle.selectionForegroundColor:this.menuStyle.foregroundColor;this.submenuIndicator&&(this.submenuIndicator.style.color=e??"")}dispose(){super.dispose(),this.hideScheduler.dispose(),this.mysubmenu&&(this.mysubmenu.dispose(),this.mysubmenu=null),this.submenuContainer&&(this.submenuContainer=void 0)}}class Si extends ci.Z4{constructor(e,t,i,s){super(e,t,i),this.menuStyles=s}render(e){super.render(e),this.label&&(this.label.style.borderBottomColor=this.menuStyles.separatorColor?`${this.menuStyles.separatorColor}`:"")}}function yi(e){const t=(0,ui.J)()[e.id];return`.codicon-${e.id}:before { content: '\\${t.toString(16)}'; }`}var wi=i(19070);class Li{constructor(e,t,i,s){this.contextViewService=e,this.telemetryService=t,this.notificationService=i,this.keybindingService=s,this.focusToReturn=null,this.lastContainer=null,this.block=null,this.blockDisposable=null,this.options={blockMouse:!0}}configure(e){this.options=e}showContextMenu(e){const t=e.getActions();if(!t.length)return;let i;this.focusToReturn=(0,U.bq)();const s=(0,U.sb)(e.domForShadowRoot)?e.domForShadowRoot:void 0;this.contextViewService.showContextView({getAnchor:()=>e.getAnchor(),canRelayout:!1,anchorAlignment:e.anchorAlignment,anchorAxisAlignment:e.anchorAxisAlignment,render:s=>{this.lastContainer=s;const n=e.getMenuClassName?e.getMenuClassName():"";n&&(s.className+=" "+n),this.options.blockMouse&&(this.block=s.appendChild((0,U.$)(".context-view-block")),this.block.style.position="fixed",this.block.style.cursor="initial",this.block.style.left="0",this.block.style.top="0",this.block.style.width="100%",this.block.style.height="100%",this.block.style.zIndex="-1",this.blockDisposable?.dispose(),this.blockDisposable=(0,U.ko)(this.block,U.Bx.MOUSE_DOWN,(e=>e.stopPropagation())));const r=new l.Cm,o=e.actionRunner||new ii.LN;o.onWillRun((t=>this.onActionRun(t,!e.skipTelemetry)),this,r),o.onDidRun(this.onDidActionRun,this,r),i=new Ci(s,t,{actionViewItemProvider:e.getActionViewItem,context:e.getActionsContext?e.getActionsContext():null,actionRunner:o,getKeyBinding:e.getKeyBinding?e.getKeyBinding:e=>this.keybindingService.lookupKeybinding(e.id)},wi.XS),i.onDidCancel((()=>this.contextViewService.hideContextView(!0)),null,r),i.onDidBlur((()=>this.contextViewService.hideContextView(!0)),null,r);const a=(0,U.zk)(s);return r.add((0,U.ko)(a,U.Bx.BLUR,(()=>this.contextViewService.hideContextView(!0)))),r.add((0,U.ko)(a,U.Bx.MOUSE_DOWN,(e=>{if(e.defaultPrevented)return;const t=new ri.P(a,e);let i=t.target;if(!t.rightButton){for(;i;){if(i===s)return;i=i.parentElement}this.contextViewService.hideContextView(!0)}}))),(0,l.qE)(r,i)},focus:()=>{i?.focus(!!e.autoSelectFirstItem)},onHide:t=>{e.onHide?.(!!t),this.block&&(this.block.remove(),this.block=null),this.blockDisposable?.dispose(),this.blockDisposable=null,this.lastContainer&&((0,U.bq)()===this.lastContainer||(0,U.QX)((0,U.bq)(),this.lastContainer))&&this.focusToReturn?.focus(),this.lastContainer=null}},s,!!s)}onActionRun(e,t){t&&this.telemetryService.publicLog2("workbenchActionExecuted",{id:e.action.id,from:"contextMenu"}),this.contextViewService.hideContextView(!1)}onDidActionRun(e){e.error&&!(0,v.MB)(e.error)&&this.notificationService.error(e.error)}}var Ri=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ti=function(e,t){return function(i,s){t(i,s,e)}};let xi=class extends l.jG{get contextMenuHandler(){return this._contextMenuHandler||(this._contextMenuHandler=new Li(this.contextViewService,this.telemetryService,this.notificationService,this.keybindingService)),this._contextMenuHandler}constructor(e,t,i,s,n,r){super(),this.telemetryService=e,this.notificationService=t,this.contextViewService=i,this.keybindingService=s,this.menuService=n,this.contextKeyService=r,this._contextMenuHandler=void 0,this._onDidShowContextMenu=this._store.add(new Q.vl),this.onDidShowContextMenu=this._onDidShowContextMenu.event,this._onDidHideContextMenu=this._store.add(new Q.vl)}configure(e){this.contextMenuHandler.configure(e)}showContextMenu(e){e=ki.transform(e,this.menuService,this.contextKeyService),this.contextMenuHandler.showContextMenu({...e,onHide:t=>{e.onHide?.(t),this._onDidHideContextMenu.fire()}}),U.Di.getInstance().resetKeyStatus(),this._onDidShowContextMenu.fire()}};var ki;xi=Ri([Ti(0,Qt.k),Ti(1,me.Ot),Ti(2,Oe.l),Ti(3,De.b),Ti(4,ni.ez),Ti(5,ie.fN)],xi),function(e){e.transform=function(e,t,i){if(!((s=e)&&s.menuId instanceof ni.D8))return e;var s;const{menuId:n,menuActionOptions:r,contextKeyService:o}=e;return{...e,getActions:()=>{const s=[];if(n){const e=t.getMenuActions(n,o??i,r);(0,si.$u)(e,s)}return e.getActions?ii.wv.join(e.getActions(),s):s}}}}(ki||(ki={}));var Ai,Ni=i(908);!function(e){e[e.API=0]="API",e[e.USER=1]="USER"}(Ai||(Ai={}));var Ii=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Oi=function(e,t){return function(i,s){t(i,s,e)}};let Di=class{constructor(e){this._commandService=e}async open(e,t){if(!(0,C.v$)(e,C.ny.command))return!1;if(!t?.allowCommands)return!0;if("string"===typeof e&&(e=h.r.parse(e)),Array.isArray(t.allowCommands)&&!t.allowCommands.includes(e.path))return!0;let i=[];try{i=(0,Ni.qg)(decodeURIComponent(e.query))}catch{try{i=(0,Ni.qg)(e.query)}catch{}}return Array.isArray(i)||(i=[i]),await this._commandService.executeCommand(e.path,...i),!0}};Di=Ii([Oi(0,St.d)],Di);let Mi=class{constructor(e){this._editorService=e}async open(e,t){"string"===typeof e&&(e=h.r.parse(e));const{selection:i,uri:s}=(0,Ue.e)(e);return(e=s).scheme===C.ny.file&&(e=(0,Jt.Fd)(e)),await this._editorService.openCodeEditor({resource:e,options:{selection:i,source:t?.fromUserGesture?Ai.USER:Ai.API,...t?.editorOptions}},this._editorService.getFocusedCodeEditor(),t?.openToSide),!0}};Mi=Ii([Oi(0,g.T)],Mi);let Pi=class{constructor(e,t){this._openers=new X.w,this._validators=new X.w,this._resolvers=new X.w,this._resolvedUriTargets=new yt.fT((e=>e.with({path:null,fragment:null,query:null}).toString())),this._externalOpeners=new X.w,this._defaultExternalOpener={openExternal:async e=>((0,C.fV)(e,C.ny.http,C.ny.https)?U.CE(e):a.G.location.href=e,!0)},this._openers.push({open:async(e,t)=>!(!t?.openExternal&&!(0,C.fV)(e,C.ny.mailto,C.ny.http,C.ny.https,C.ny.vsls))&&(await this._doOpenExternal(e,t),!0)}),this._openers.push(new Di(t)),this._openers.push(new Mi(e))}registerOpener(e){return{dispose:this._openers.unshift(e)}}async open(e,t){const i="string"===typeof e?h.r.parse(e):e,s=this._resolvedUriTargets.get(i)??e;for(const n of this._validators)if(!await n.shouldOpen(s,t))return!1;for(const n of this._openers){if(await n.open(e,t))return!0}return!1}async resolveExternalUri(e,t){for(const i of this._resolvers)try{const s=await i.resolveExternalUri(e,t);if(s)return this._resolvedUriTargets.has(s.resolved)||this._resolvedUriTargets.set(s.resolved,e),s}catch{}throw new Error("Could not resolve external URI: "+e.toString())}async _doOpenExternal(e,t){const i="string"===typeof e?h.r.parse(e):e;let s,n;try{s=(await this.resolveExternalUri(i,t)).resolved}catch{s=i}if(n="string"===typeof e&&i.toString()===s.toString()?e:encodeURI(s.toString(!0)),t?.allowContributedOpeners){const e="string"===typeof t?.allowContributedOpeners?t?.allowContributedOpeners:void 0;for(const t of this._externalOpeners){if(await t.openExternal(n,{sourceUri:i,preferredOpenerId:e},at.XO.None))return!0}}return this._defaultExternalOpener.openExternal(n,{sourceUri:i},at.XO.None)}dispose(){this._validators.clear()}};Pi=Ii([Oi(0,g.T),Oi(1,St.d)],Pi);var Fi=i(10920),Ui=i(10154),Hi=i(30707),Bi=i(37550),Wi=i(16363),Vi=i(71597),zi=i(51467),Gi=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ji=function(e,t){return function(i,s){t(i,s,e)}};let Ki=class extends l.jG{constructor(e,t){super(),this.quickInputService=e,this.instantiationService=t,this.registry=Lt.O.as(Vi.Fd.Quickaccess),this.mapProviderToDescriptor=new Map,this.lastAcceptedPickerValues=new Map,this.visibleQuickAccess=void 0}show(e="",t){this.doShowOrPick(e,!1,t)}doShowOrPick(e,t,i){const[s,n]=this.getOrInstantiateProvider(e,i?.enabledProviderPrefixes),r=this.visibleQuickAccess,o=r?.descriptor;if(r&&n&&o===n)return e===n.prefix||i?.preserveValue||(r.picker.value=e),void this.adjustValueSelection(r.picker,n,i);if(n&&!i?.preserveValue){let t;if(r&&o&&o!==n){const e=r.value.substr(o.prefix.length);e&&(t=`${n.prefix}${e}`)}if(!t){const e=s?.defaultFilterValue;e===Vi.aJ.LAST?t=this.lastAcceptedPickerValues.get(n):"string"===typeof e&&(t=`${n.prefix}${e}`)}"string"===typeof t&&(e=t)}const a=r?.picker?.valueSelection,c=r?.picker?.value,h=new l.Cm,d=h.add(this.quickInputService.createQuickPick({useSeparators:!0}));let u;d.value=e,this.adjustValueSelection(d,n,i),d.placeholder=i?.placeholder??n?.placeholder,d.quickNavigate=i?.quickNavigateConfiguration,d.hideInput=!!d.quickNavigate&&!r,("number"===typeof i?.itemActivation||i?.quickNavigateConfiguration)&&(d.itemActivation=i?.itemActivation??zi.C1.SECOND),d.contextKey=n?.contextKey,d.filterValue=e=>e.substring(n?n.prefix.length:0),t&&(u=new m.Zv,h.add(Q.Jh.once(d.onWillAccept)((e=>{e.veto(),d.hide()})))),h.add(this.registerPickerListeners(d,s,n,e,i));const g=h.add(new at.Qi);return s&&h.add(s.provide(d,g.token,i?.providerOptions)),Q.Jh.once(d.onDidHide)((()=>{0===d.selectedItems.length&&g.cancel(),h.dispose(),u?.complete(d.selectedItems.slice(0))})),d.show(),a&&c===e&&(d.valueSelection=a),t?u?.p:void 0}adjustValueSelection(e,t,i){let s;s=i?.preserveValue?[e.value.length,e.value.length]:[t?.prefix.length??0,e.value.length],e.valueSelection=s}registerPickerListeners(e,t,i,s,n){const r=new l.Cm,o=this.visibleQuickAccess={picker:e,descriptor:i,value:s};return r.add((0,l.s)((()=>{o===this.visibleQuickAccess&&(this.visibleQuickAccess=void 0)}))),r.add(e.onDidChangeValue((e=>{const[i]=this.getOrInstantiateProvider(e,n?.enabledProviderPrefixes);i!==t?this.show(e,{enabledProviderPrefixes:n?.enabledProviderPrefixes,preserveValue:!0,providerOptions:n?.providerOptions}):o.value=e}))),i&&r.add(e.onDidAccept((()=>{this.lastAcceptedPickerValues.set(i,e.value)}))),r}getOrInstantiateProvider(e,t){const i=this.registry.getQuickAccessProvider(e);if(!i||t&&!t?.includes(i.prefix))return[void 0,void 0];let s=this.mapProviderToDescriptor.get(i);return s||(s=this.instantiationService.createInstance(i.ctor),this.mapProviderToDescriptor.set(i,s)),[s,i]}};Ki=Gi([ji(0,zi.GK),ji(1,ae._Y)],Ki);var Yi=i(35315),qi=i(56245),$i=i(20370),Qi=i(96032),Xi=i(58694),Zi=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};class Ji{constructor(e){this.nodes=e}toString(){return this.nodes.map((e=>"string"===typeof e?e:e.label)).join("")}}Zi([Xi.B],Ji.prototype,"toString",null);const es=/\[([^\]]+)\]\(((?:https?:\/\/|command:|file:)[^\)\s]+)(?: (["'])(.+?)(\3))?\)/gi;const ts={},is=new Qi.n("quick-input-button-icon-");function ss(e,t,i){let s=e.iconClass||function(e){if(!e)return;let t;const i=e.dark.toString();return ts[i]?t=ts[i]:(t=is.nextId(),U.Wt(`.${t}, .hc-light .${t}`,`background-image: ${U.Tf(e.light||e.dark)}`),U.Wt(`.vs-dark .${t}, .hc-black .${t}`,`background-image: ${U.Tf(e.dark)}`),ts[i]=t),t}(e.iconPath);return e.alwaysVisible&&(s=s?`${s} always-visible`:"always-visible"),{id:t,label:"",tooltip:e.tooltip||"",class:s,enabled:!0,run:i}}function ns(e,t,i){U.Ln(t);const s=function(e){const t=[];let i,s=0;for(;i=es.exec(e);){i.index-s>0&&t.push(e.substring(s,i.index));const[,n,r,,o]=i;o?t.push({label:n,href:r,title:o}):t.push({label:n,href:r}),s=i.index+i[0].length}return s{U.sd(e)&&U.fs.stop(e,!0),i.callback(r.href)},a=i.disposables.add(new qi.f(s,U.Bx.CLICK)).event,l=i.disposables.add(new qi.f(s,U.Bx.KEY_DOWN)).event,c=Q.Jh.chain(l,(e=>e.filter((e=>{const t=new Xe.Z(e);return t.equals(10)||t.equals(3)}))));i.disposables.add(ai.q.addTarget(s));const h=i.disposables.add(new qi.f(s,ai.B.Tap)).event;Q.Jh.any(a,h,c)(o,null,i.disposables),t.appendChild(s)}}var rs=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},os=function(e,t){return function(i,s){t(i,s,e)}};const as="inQuickInput",ls=new ie.N1(as,!1,(0,E.kg)("inQuickInput","Whether keyboard focus is inside the quick input control")),cs=ie.M$.has(as),hs="quickInputType",ds=new ie.N1(hs,void 0,(0,E.kg)("quickInputType","The type of the currently visible quick input")),us="cursorAtEndOfQuickInputBox",gs=new ie.N1(us,!1,(0,E.kg)("cursorAtEndOfQuickInputBox","Whether the cursor in the quick input is at the end of the input box")),ps=ie.M$.has(us),ms={iconClass:gi.L.asClassName(di.W.quickInputBack),tooltip:(0,E.kg)("quickInput.back","Back"),handle:-1};class fs extends l.jG{static{this.noPromptMessage=(0,E.kg)("inputModeEntry","Press 'Enter' to confirm your input or 'Escape' to cancel")}constructor(e){super(),this.ui=e,this._widgetUpdated=!1,this.visible=!1,this._enabled=!0,this._busy=!1,this._ignoreFocusOut=!1,this._leftButtons=[],this._rightButtons=[],this._inlineButtons=[],this.buttonsUpdated=!1,this._toggles=[],this.togglesUpdated=!1,this.noValidationMessage=fs.noPromptMessage,this._severity=ge.A.Ignore,this.onDidTriggerButtonEmitter=this._register(new Q.vl),this.onDidHideEmitter=this._register(new Q.vl),this.onWillHideEmitter=this._register(new Q.vl),this.onDisposeEmitter=this._register(new Q.vl),this.visibleDisposables=this._register(new l.Cm),this.onDidHide=this.onDidHideEmitter.event}get title(){return this._title}set title(e){this._title=e,this.update()}get description(){return this._description}set description(e){this._description=e,this.update()}get step(){return this._steps}set step(e){this._steps=e,this.update()}get totalSteps(){return this._totalSteps}set totalSteps(e){this._totalSteps=e,this.update()}get enabled(){return this._enabled}set enabled(e){this._enabled=e,this.update()}get contextKey(){return this._contextKey}set contextKey(e){this._contextKey=e,this.update()}get busy(){return this._busy}set busy(e){this._busy=e,this.update()}get ignoreFocusOut(){return this._ignoreFocusOut}set ignoreFocusOut(e){const t=this._ignoreFocusOut!==e&&!We.un;this._ignoreFocusOut=e&&!We.un,t&&this.update()}get titleButtons(){return this._leftButtons.length?[...this._leftButtons,this._rightButtons]:this._rightButtons}get buttons(){return[...this._leftButtons,...this._rightButtons,...this._inlineButtons]}set buttons(e){this._leftButtons=e.filter((e=>e===ms)),this._rightButtons=e.filter((e=>e!==ms&&e.location!==zi.dH.Inline)),this._inlineButtons=e.filter((e=>e.location===zi.dH.Inline)),this.buttonsUpdated=!0,this.update()}get toggles(){return this._toggles}set toggles(e){this._toggles=e??[],this.togglesUpdated=!0,this.update()}get validationMessage(){return this._validationMessage}set validationMessage(e){this._validationMessage=e,this.update()}get severity(){return this._severity}set severity(e){this._severity=e,this.update()}show(){this.visible||(this.visibleDisposables.add(this.ui.onDidTriggerButton((e=>{-1!==this.buttons.indexOf(e)&&this.onDidTriggerButtonEmitter.fire(e)}))),this.ui.show(this),this.visible=!0,this._lastValidationMessage=void 0,this._lastSeverity=void 0,this.buttons.length&&(this.buttonsUpdated=!0),this.toggles.length&&(this.togglesUpdated=!0),this.update())}hide(){this.visible&&this.ui.hide()}didHide(e=zi.kF.Other){this.visible=!1,this.visibleDisposables.clear(),this.onDidHideEmitter.fire({reason:e})}willHide(e=zi.kF.Other){this.onWillHideEmitter.fire({reason:e})}update(){if(!this.visible)return;const e=this.getTitle();e&&this.ui.title.textContent!==e?this.ui.title.textContent=e:e||" "===this.ui.title.innerHTML||(this.ui.title.innerText="\xa0");const t=this.getDescription();if(this.ui.description1.textContent!==t&&(this.ui.description1.textContent=t),this.ui.description2.textContent!==t&&(this.ui.description2.textContent=t),this._widgetUpdated&&(this._widgetUpdated=!1,this._widget?U.Ln(this.ui.widget,this._widget):U.Ln(this.ui.widget)),this.busy&&!this.busyDelay&&(this.busyDelay=new m.pc,this.busyDelay.setIfNotSet((()=>{this.visible&&this.ui.progressBar.infinite()}),800)),!this.busy&&this.busyDelay&&(this.ui.progressBar.stop(),this.busyDelay.cancel(),this.busyDelay=void 0),this.buttonsUpdated){this.buttonsUpdated=!1,this.ui.leftActionBar.clear();const e=this._leftButtons.map(((e,t)=>ss(e,`id-${t}`,(async()=>this.onDidTriggerButtonEmitter.fire(e)))));this.ui.leftActionBar.push(e,{icon:!0,label:!1}),this.ui.rightActionBar.clear();const t=this._rightButtons.map(((e,t)=>ss(e,`id-${t}`,(async()=>this.onDidTriggerButtonEmitter.fire(e)))));this.ui.rightActionBar.push(t,{icon:!0,label:!1}),this.ui.inlineActionBar.clear();const i=this._inlineButtons.map(((e,t)=>ss(e,`id-${t}`,(async()=>this.onDidTriggerButtonEmitter.fire(e)))));this.ui.inlineActionBar.push(i,{icon:!0,label:!1})}if(this.togglesUpdated){this.togglesUpdated=!1;const e=this.toggles?.filter((e=>e instanceof Yi.l))??[];this.ui.inputBox.toggles=e}this.ui.ignoreFocusOut=this.ignoreFocusOut,this.ui.setEnabled(this.enabled),this.ui.setContextKey(this.contextKey);const i=this.validationMessage||this.noValidationMessage;this._lastValidationMessage!==i&&(this._lastValidationMessage=i,U.Ln(this.ui.message),ns(i,this.ui.message,{callback:e=>{this.ui.linkOpenerDelegate(e)},disposables:this.visibleDisposables})),this._lastSeverity!==this.severity&&(this._lastSeverity=this.severity,this.showMessageDecoration(this.severity))}getTitle(){return this.title&&this.step?`${this.title} (${this.getSteps()})`:this.title?this.title:this.step?this.getSteps():""}getDescription(){return this.description||""}getSteps(){return this.step&&this.totalSteps?(0,E.kg)("quickInput.steps","{0}/{1}",this.step,this.totalSteps):this.step?String(this.step):""}showMessageDecoration(e){if(this.ui.inputBox.showDecoration(e),e!==ge.A.Ignore){const t=this.ui.inputBox.stylesForType(e);this.ui.message.style.color=t.foreground?`${t.foreground}`:"",this.ui.message.style.backgroundColor=t.background?`${t.background}`:"",this.ui.message.style.border=t.border?`1px solid ${t.border}`:"",this.ui.message.style.marginBottom="-2px"}else this.ui.message.style.color="",this.ui.message.style.backgroundColor="",this.ui.message.style.border="",this.ui.message.style.marginBottom=""}dispose(){this.hide(),this.onDisposeEmitter.fire(),super.dispose()}}class _s extends fs{constructor(){super(...arguments),this._value="",this.onDidChangeValueEmitter=this._register(new Q.vl),this.onWillAcceptEmitter=this._register(new Q.vl),this.onDidAcceptEmitter=this._register(new Q.vl),this.onDidCustomEmitter=this._register(new Q.vl),this._items=[],this.itemsUpdated=!1,this._canSelectMany=!1,this._canAcceptInBackground=!1,this._matchOnDescription=!1,this._matchOnDetail=!1,this._matchOnLabel=!0,this._matchOnLabelMode="fuzzy",this._sortByLabel=!0,this._keepScrollPosition=!1,this._itemActivation=zi.C1.FIRST,this._activeItems=[],this.activeItemsUpdated=!1,this.activeItemsToConfirm=[],this.onDidChangeActiveEmitter=this._register(new Q.vl),this._selectedItems=[],this.selectedItemsUpdated=!1,this.selectedItemsToConfirm=[],this.onDidChangeSelectionEmitter=this._register(new Q.vl),this.onDidTriggerItemButtonEmitter=this._register(new Q.vl),this.onDidTriggerSeparatorButtonEmitter=this._register(new Q.vl),this.valueSelectionUpdated=!0,this._ok="default",this._customButton=!1,this._focusEventBufferer=new Q.at,this.type="quickPick",this.filterValue=e=>e,this.onDidChangeValue=this.onDidChangeValueEmitter.event,this.onWillAccept=this.onWillAcceptEmitter.event,this.onDidAccept=this.onDidAcceptEmitter.event,this.onDidChangeActive=this.onDidChangeActiveEmitter.event,this.onDidChangeSelection=this.onDidChangeSelectionEmitter.event,this.onDidTriggerItemButton=this.onDidTriggerItemButtonEmitter.event,this.onDidTriggerSeparatorButton=this.onDidTriggerSeparatorButtonEmitter.event}static{this.DEFAULT_ARIA_LABEL=(0,E.kg)("quickInputBox.ariaLabel","Type to narrow down results.")}get quickNavigate(){return this._quickNavigate}set quickNavigate(e){this._quickNavigate=e,this.update()}get value(){return this._value}set value(e){this.doSetValue(e)}doSetValue(e,t){if(this._value!==e){if(this._value=e,t||this.update(),this.visible){this.ui.list.filter(this.filterValue(this._value))&&this.trySelectFirst()}this.onDidChangeValueEmitter.fire(this._value)}}set ariaLabel(e){this._ariaLabel=e,this.update()}get ariaLabel(){return this._ariaLabel}get placeholder(){return this._placeholder}set placeholder(e){this._placeholder=e,this.update()}get items(){return this._items}get scrollTop(){return this.ui.list.scrollTop}set scrollTop(e){this.ui.list.scrollTop=e}set items(e){this._items=e,this.itemsUpdated=!0,this.update()}get canSelectMany(){return this._canSelectMany}set canSelectMany(e){this._canSelectMany=e,this.update()}get canAcceptInBackground(){return this._canAcceptInBackground}set canAcceptInBackground(e){this._canAcceptInBackground=e}get matchOnDescription(){return this._matchOnDescription}set matchOnDescription(e){this._matchOnDescription=e,this.update()}get matchOnDetail(){return this._matchOnDetail}set matchOnDetail(e){this._matchOnDetail=e,this.update()}get matchOnLabel(){return this._matchOnLabel}set matchOnLabel(e){this._matchOnLabel=e,this.update()}get matchOnLabelMode(){return this._matchOnLabelMode}set matchOnLabelMode(e){this._matchOnLabelMode=e,this.update()}get sortByLabel(){return this._sortByLabel}set sortByLabel(e){this._sortByLabel=e,this.update()}get keepScrollPosition(){return this._keepScrollPosition}set keepScrollPosition(e){this._keepScrollPosition=e}get itemActivation(){return this._itemActivation}set itemActivation(e){this._itemActivation=e}get activeItems(){return this._activeItems}set activeItems(e){this._activeItems=e,this.activeItemsUpdated=!0,this.update()}get selectedItems(){return this._selectedItems}set selectedItems(e){this._selectedItems=e,this.selectedItemsUpdated=!0,this.update()}get keyMods(){return this._quickNavigate?zi.Ym:this.ui.keyMods}get valueSelection(){const e=this.ui.inputBox.getSelection();if(e)return[e.start,e.end]}set valueSelection(e){this._valueSelection=e,this.valueSelectionUpdated=!0,this.update()}get customButton(){return this._customButton}set customButton(e){this._customButton=e,this.update()}get customLabel(){return this._customButtonLabel}set customLabel(e){this._customButtonLabel=e,this.update()}get customHover(){return this._customButtonHover}set customHover(e){this._customButtonHover=e,this.update()}get ok(){return this._ok}set ok(e){this._ok=e,this.update()}get hideInput(){return!!this._hideInput}set hideInput(e){this._hideInput=e,this.update()}trySelectFirst(){this.canSelectMany||this.ui.list.focus(zi.Fp.First)}show(){this.visible||(this.visibleDisposables.add(this.ui.inputBox.onDidChange((e=>{this.doSetValue(e,!0)}))),this.visibleDisposables.add(this.ui.onDidAccept((()=>{this.canSelectMany?this.ui.list.getCheckedElements().length||(this._selectedItems=[],this.onDidChangeSelectionEmitter.fire(this.selectedItems)):this.activeItems[0]&&(this._selectedItems=[this.activeItems[0]],this.onDidChangeSelectionEmitter.fire(this.selectedItems)),this.handleAccept(!1)}))),this.visibleDisposables.add(this.ui.onDidCustom((()=>{this.onDidCustomEmitter.fire()}))),this.visibleDisposables.add(this._focusEventBufferer.wrapEvent(this.ui.list.onDidChangeFocus,((e,t)=>t))((e=>{this.activeItemsUpdated||this.activeItemsToConfirm!==this._activeItems&&(0,b.aI)(e,this._activeItems,((e,t)=>e===t))||(this._activeItems=e,this.onDidChangeActiveEmitter.fire(e))}))),this.visibleDisposables.add(this.ui.list.onDidChangeSelection((({items:e,event:t})=>{this.canSelectMany?e.length&&this.ui.list.setSelectedElements([]):this.selectedItemsToConfirm!==this._selectedItems&&(0,b.aI)(e,this._selectedItems,((e,t)=>e===t))||(this._selectedItems=e,this.onDidChangeSelectionEmitter.fire(e),e.length&&this.handleAccept(U.Er(t)&&1===t.button))}))),this.visibleDisposables.add(this.ui.list.onChangedCheckedElements((e=>{this.canSelectMany&&this.visible&&(this.selectedItemsToConfirm!==this._selectedItems&&(0,b.aI)(e,this._selectedItems,((e,t)=>e===t))||(this._selectedItems=e,this.onDidChangeSelectionEmitter.fire(e)))}))),this.visibleDisposables.add(this.ui.list.onButtonTriggered((e=>this.onDidTriggerItemButtonEmitter.fire(e)))),this.visibleDisposables.add(this.ui.list.onSeparatorButtonTriggered((e=>this.onDidTriggerSeparatorButtonEmitter.fire(e)))),this.visibleDisposables.add(this.registerQuickNavigation()),this.valueSelectionUpdated=!0),super.show()}handleAccept(e){let t=!1;this.onWillAcceptEmitter.fire({veto:()=>t=!0}),t||this.onDidAcceptEmitter.fire({inBackground:e})}registerQuickNavigation(){return U.ko(this.ui.container,U.Bx.KEY_UP,(e=>{if(this.canSelectMany||!this._quickNavigate)return;const t=new Xe.Z(e),i=t.keyCode;this._quickNavigate.keybindings.some((e=>{const s=e.getChords();return!(s.length>1)&&(s[0].shiftKey&&4===i?!(t.ctrlKey||t.altKey||t.metaKey):!(!s[0].altKey||6!==i)||(!(!s[0].ctrlKey||5!==i)||!(!s[0].metaKey||57!==i)))}))&&(this.activeItems[0]&&(this._selectedItems=[this.activeItems[0]],this.onDidChangeSelectionEmitter.fire(this.selectedItems),this.handleAccept(!1)),this._quickNavigate=void 0)}))}update(){if(!this.visible)return;const e=this.keepScrollPosition?this.scrollTop:0,t=!!this.description,i={title:!!this.title||!!this.step||!!this.titleButtons.length,description:t,checkAll:this.canSelectMany&&!this._hideCheckAll,checkBox:this.canSelectMany,inputBox:!this._hideInput,progressBar:!this._hideInput||t,visibleCount:!0,count:this.canSelectMany&&!this._hideCountBadge,ok:"default"===this.ok?this.canSelectMany:this.ok,list:!0,message:!!this.validationMessage,customButton:this.customButton};this.ui.setVisibilities(i),super.update(),this.ui.inputBox.value!==this.value&&(this.ui.inputBox.value=this.value),this.valueSelectionUpdated&&(this.valueSelectionUpdated=!1,this.ui.inputBox.select(this._valueSelection&&{start:this._valueSelection[0],end:this._valueSelection[1]})),this.ui.inputBox.placeholder!==(this.placeholder||"")&&(this.ui.inputBox.placeholder=this.placeholder||"");let s=this.ariaLabel;!s&&i.inputBox&&(s=this.placeholder||_s.DEFAULT_ARIA_LABEL,this.title&&(s+=` - ${this.title}`)),this.ui.list.ariaLabel!==s&&(this.ui.list.ariaLabel=s??null),this.ui.list.matchOnDescription=this.matchOnDescription,this.ui.list.matchOnDetail=this.matchOnDetail,this.ui.list.matchOnLabel=this.matchOnLabel,this.ui.list.matchOnLabelMode=this.matchOnLabelMode,this.ui.list.sortByLabel=this.sortByLabel,this.itemsUpdated&&(this.itemsUpdated=!1,this._focusEventBufferer.bufferEvents((()=>{switch(this.ui.list.setElements(this.items),this.ui.list.shouldLoop=!this.canSelectMany,this.ui.list.filter(this.filterValue(this.ui.inputBox.value)),this._itemActivation){case zi.C1.NONE:this._itemActivation=zi.C1.FIRST;break;case zi.C1.SECOND:this.ui.list.focus(zi.Fp.Second),this._itemActivation=zi.C1.FIRST;break;case zi.C1.LAST:this.ui.list.focus(zi.Fp.Last),this._itemActivation=zi.C1.FIRST;break;default:this.trySelectFirst()}}))),this.ui.container.classList.contains("show-checkboxes")!==!!this.canSelectMany&&(this.canSelectMany?this.ui.list.clearFocus():this.trySelectFirst()),this.activeItemsUpdated&&(this.activeItemsUpdated=!1,this.activeItemsToConfirm=this._activeItems,this.ui.list.setFocusedElements(this.activeItems),this.activeItemsToConfirm===this._activeItems&&(this.activeItemsToConfirm=null)),this.selectedItemsUpdated&&(this.selectedItemsUpdated=!1,this.selectedItemsToConfirm=this._selectedItems,this.canSelectMany?this.ui.list.setCheckedElements(this.selectedItems):this.ui.list.setSelectedElements(this.selectedItems),this.selectedItemsToConfirm===this._selectedItems&&(this.selectedItemsToConfirm=null)),this.ui.customButton.label=this.customLabel||"",this.ui.customButton.element.title=this.customHover||"",i.inputBox||(this.ui.list.domFocus(),this.canSelectMany&&this.ui.list.focus(zi.Fp.First)),this.keepScrollPosition&&(this.scrollTop=e)}focus(e){this.ui.list.focus(e),this.canSelectMany&&this.ui.list.domFocus()}accept(e){e&&!this._canAcceptInBackground||this.activeItems[0]&&(this._selectedItems=[this.activeItems[0]],this.onDidChangeSelectionEmitter.fire(this.selectedItems),this.handleAccept(e??!1))}}class vs extends fs{constructor(){super(...arguments),this._value="",this.valueSelectionUpdated=!0,this._password=!1,this.onDidValueChangeEmitter=this._register(new Q.vl),this.onDidAcceptEmitter=this._register(new Q.vl),this.type="inputBox",this.onDidChangeValue=this.onDidValueChangeEmitter.event,this.onDidAccept=this.onDidAcceptEmitter.event}get value(){return this._value}set value(e){this._value=e||"",this.update()}get placeholder(){return this._placeholder}set placeholder(e){this._placeholder=e,this.update()}get password(){return this._password}set password(e){this._password=e,this.update()}show(){this.visible||(this.visibleDisposables.add(this.ui.inputBox.onDidChange((e=>{e!==this.value&&(this._value=e,this.onDidValueChangeEmitter.fire(e))}))),this.visibleDisposables.add(this.ui.onDidAccept((()=>this.onDidAcceptEmitter.fire()))),this.valueSelectionUpdated=!0),super.show()}update(){if(!this.visible)return;this.ui.container.classList.remove("hidden-input");const e={title:!!this.title||!!this.step||!!this.titleButtons.length,description:!!this.description||!!this.step,inputBox:!0,message:!0,progressBar:!0};this.ui.setVisibilities(e),super.update(),this.ui.inputBox.value!==this.value&&(this.ui.inputBox.value=this.value),this.valueSelectionUpdated&&(this.valueSelectionUpdated=!1,this.ui.inputBox.select(this._valueSelection&&{start:this._valueSelection[0],end:this._valueSelection[1]})),this.ui.inputBox.placeholder!==(this.placeholder||"")&&(this.ui.inputBox.placeholder=this.placeholder||""),this.ui.inputBox.password!==this.password&&(this.ui.inputBox.password=this.password)}}let Cs=class extends Ie.fO{constructor(e,t){super("element",!1,(e=>this.getOverrideOptions(e)),e,t)}getOverrideOptions(e){return{persistence:{hideOnKeyDown:!1},appearance:{showHoverHint:(U.sb(e.content)?e.content.textContent??"":"string"===typeof e.content?e.content:e.content.value).includes("\n"),skipFadeInAnimation:!0}}}};Cs=rs([os(0,Me.pG),os(1,Ie.TN)],Cs);var bs=i(62890),Es=i(3828);const Ss="done",ys="active",ws="infinite",Ls="infinite-long-running",Rs="discrete";class Ts extends l.jG{static{this.LONG_RUNNING_INFINITE_THRESHOLD=1e4}constructor(e,t){super(),this.progressSignal=this._register(new l.HE),this.workedVal=0,this.showDelayedScheduler=this._register(new m.uC((()=>(0,U.WU)(this.element)),0)),this.longRunningScheduler=this._register(new m.uC((()=>this.infiniteLongRunning()),Ts.LONG_RUNNING_INFINITE_THRESHOLD)),this.create(e,t)}create(e,t){this.element=document.createElement("div"),this.element.classList.add("monaco-progress-container"),this.element.setAttribute("role","progressbar"),this.element.setAttribute("aria-valuemin","0"),e.appendChild(this.element),this.bit=document.createElement("div"),this.bit.classList.add("progress-bit"),this.bit.style.backgroundColor=t?.progressBarBackground||"#0E70C0",this.element.appendChild(this.bit)}off(){this.bit.style.width="inherit",this.bit.style.opacity="1",this.element.classList.remove(ys,ws,Ls,Rs),this.workedVal=0,this.totalWork=void 0,this.longRunningScheduler.cancel(),this.progressSignal.clear()}stop(){return this.doDone(!1)}doDone(e){return this.element.classList.add(Ss),this.element.classList.contains(ws)?(this.bit.style.opacity="0",e?setTimeout((()=>this.off()),200):this.off()):(this.bit.style.width="inherit",e?setTimeout((()=>this.off()),200):this.off()),this}infinite(){return this.bit.style.width="2%",this.bit.style.opacity="1",this.element.classList.remove(Rs,Ss,Ls),this.element.classList.add(ys,ws),this.longRunningScheduler.schedule(),this}infiniteLongRunning(){this.element.classList.add(Ls)}getContainer(){return this.element}}var xs=i(88443);const ks=U.$;class As extends l.jG{constructor(e,t,i){super(),this.parent=e,this.onKeyDown=e=>U.b2(this.findInput.inputBox.inputElement,U.Bx.KEY_DOWN,e),this.onDidChange=e=>this.findInput.onDidChange(e),this.container=U.BC(this.parent,ks(".quick-input-box")),this.findInput=this._register(new xs.c(this.container,void 0,{label:"",inputBoxStyles:t,toggleStyles:i}));const s=this.findInput.inputBox.inputElement;s.role="combobox",s.ariaHasPopup="menu",s.ariaAutoComplete="list",s.ariaExpanded="true"}get value(){return this.findInput.getValue()}set value(e){this.findInput.setValue(e)}select(e=null){this.findInput.inputBox.select(e)}getSelection(){return this.findInput.inputBox.getSelection()}isSelectionAtEnd(){return this.findInput.inputBox.isSelectionAtEnd()}get placeholder(){return this.findInput.inputBox.inputElement.getAttribute("placeholder")||""}set placeholder(e){this.findInput.inputBox.setPlaceHolder(e)}get password(){return"password"===this.findInput.inputBox.inputElement.type}set password(e){this.findInput.inputBox.inputElement.type=e?"password":"text"}set enabled(e){this.findInput.inputBox.inputElement.toggleAttribute("readonly",!e)}set toggles(e){this.findInput.setAdditionalToggles(e)}setAttribute(e,t){this.findInput.inputBox.inputElement.setAttribute(e,t)}showDecoration(e){e===ge.A.Ignore?this.findInput.clearMessage():this.findInput.showMessage({type:e===ge.A.Info?1:e===ge.A.Warning?2:3,content:""})}stylesForType(e){return this.findInput.inputBox.stylesForType(e===ge.A.Info?1:e===ge.A.Warning?2:3)}setFocus(){this.findInput.focus()}layout(){this.findInput.inputBox.layout()}}var Ns=i(36584),Is=i(21852),Os=i(47625),Ds=i(86723),Ms=i(91090);const Ps=new Ms.d((()=>{const e=new Intl.Collator(void 0,{numeric:!0,sensitivity:"base"});return{collator:e,collatorIsNumeric:e.resolvedOptions().numeric}}));new Ms.d((()=>({collator:new Intl.Collator(void 0,{numeric:!0})}))),new Ms.d((()=>({collator:new Intl.Collator(void 0,{numeric:!0,sensitivity:"accent"})})));function Fs(e,t,i){const s=e.toLowerCase(),n=t.toLowerCase(),r=function(e,t,i){const s=e.toLowerCase(),n=t.toLowerCase(),r=s.startsWith(i),o=n.startsWith(i);if(r!==o)return r?-1:1;if(r&&o){if(s.lengthn.length)return 1}return 0}(e,t,i);if(r)return r;const o=s.endsWith(i);if(o!==n.endsWith(i))return o?-1:1;const a=function(e,t){const i=e||"",s=t||"",n=Ps.value.collator.compare(i,s);return Ps.value.collatorIsNumeric&&0===n&&i!==s?i=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Vs=function(e,t){return function(i,s){t(i,s,e)}};const zs=U.$;class Gs{constructor(e,t,i){this.index=e,this.hasCheckbox=t,this._hidden=!1,this._init=new Ms.d((()=>{const e=i.label??"",t=(0,pi._k)(e).text.trim(),s=i.ariaLabel||[e,this.saneDescription,this.saneDetail].map((e=>(0,pi.R$)(e))).filter((e=>!!e)).join(", ");return{saneLabel:e,saneSortLabel:t,saneAriaLabel:s}})),this._saneDescription=i.description,this._saneTooltip=i.tooltip}get saneLabel(){return this._init.value.saneLabel}get saneSortLabel(){return this._init.value.saneSortLabel}get saneAriaLabel(){return this._init.value.saneAriaLabel}get element(){return this._element}set element(e){this._element=e}get hidden(){return this._hidden}set hidden(e){this._hidden=e}get saneDescription(){return this._saneDescription}set saneDescription(e){this._saneDescription=e}get saneDetail(){return this._saneDetail}set saneDetail(e){this._saneDetail=e}get saneTooltip(){return this._saneTooltip}set saneTooltip(e){this._saneTooltip=e}get labelHighlights(){return this._labelHighlights}set labelHighlights(e){this._labelHighlights=e}get descriptionHighlights(){return this._descriptionHighlights}set descriptionHighlights(e){this._descriptionHighlights=e}get detailHighlights(){return this._detailHighlights}set detailHighlights(e){this._detailHighlights=e}}class js extends Gs{constructor(e,t,i,s,n,r){super(e,t,n),this.fireButtonTriggered=i,this._onChecked=s,this.item=n,this._separator=r,this._checked=!1,this.onChecked=t?Q.Jh.map(Q.Jh.filter(this._onChecked.event,(e=>e.element===this)),(e=>e.checked)):Q.Jh.None,this._saneDetail=n.detail,this._labelHighlights=n.highlights?.label,this._descriptionHighlights=n.highlights?.description,this._detailHighlights=n.highlights?.detail}get separator(){return this._separator}set separator(e){this._separator=e}get checked(){return this._checked}set checked(e){e!==this._checked&&(this._checked=e,this._onChecked.fire({element:this,checked:e}))}get checkboxDisabled(){return!!this.item.disabled}}var Ks;!function(e){e[e.NONE=0]="NONE",e[e.MOUSE_HOVER=1]="MOUSE_HOVER",e[e.ACTIVE_ITEM=2]="ACTIVE_ITEM"}(Ks||(Ks={}));class Ys extends Gs{constructor(e,t,i){super(e,!1,i),this.fireSeparatorButtonTriggered=t,this.separator=i,this.children=new Array,this.focusInsideSeparator=Ks.NONE}}class qs{getHeight(e){return e instanceof Ys?30:e.saneDetail?44:22}getTemplateId(e){return e instanceof js?Xs.ID:Zs.ID}}class $s{getWidgetAriaLabel(){return(0,E.kg)("quickInput","Quick Input")}getAriaLabel(e){return e.separator?.label?`${e.saneAriaLabel}, ${e.separator.label}`:e.saneAriaLabel}getWidgetRole(){return"listbox"}getRole(e){return e.hasCheckbox?"checkbox":"option"}isChecked(e){if(e.hasCheckbox&&e instanceof js)return{get value(){return e.checked},onDidChange:t=>e.onChecked((()=>t()))}}}class Qs{constructor(e){this.hoverDelegate=e}renderTemplate(e){const t=Object.create(null);t.toDisposeElement=new l.Cm,t.toDisposeTemplate=new l.Cm,t.entry=U.BC(e,zs(".quick-input-list-entry"));const i=U.BC(t.entry,zs("label.quick-input-list-label"));t.toDisposeTemplate.add(U.b2(i,U.Bx.CLICK,(e=>{t.checkbox.offsetParent||e.preventDefault()}))),t.checkbox=U.BC(i,zs("input.quick-input-list-checkbox")),t.checkbox.type="checkbox";const s=U.BC(i,zs(".quick-input-list-rows")),n=U.BC(s,zs(".quick-input-list-row")),r=U.BC(s,zs(".quick-input-list-row"));t.label=new Is.s(n,{supportHighlights:!0,supportDescriptionHighlights:!0,supportIcons:!0,hoverDelegate:this.hoverDelegate}),t.toDisposeTemplate.add(t.label),t.icon=U.Hs(t.label.element,zs(".quick-input-list-icon"));const o=U.BC(n,zs(".quick-input-list-entry-keybinding"));t.keybinding=new Os.x(o,We.OS),t.toDisposeTemplate.add(t.keybinding);const a=U.BC(r,zs(".quick-input-list-label-meta"));return t.detail=new Is.s(a,{supportHighlights:!0,supportIcons:!0,hoverDelegate:this.hoverDelegate}),t.toDisposeTemplate.add(t.detail),t.separator=U.BC(t.entry,zs(".quick-input-list-separator")),t.actionBar=new li.E(t.entry,this.hoverDelegate?{hoverDelegate:this.hoverDelegate}:void 0),t.actionBar.domNode.classList.add("quick-input-list-entry-action-bar"),t.toDisposeTemplate.add(t.actionBar),t}disposeTemplate(e){e.toDisposeElement.dispose(),e.toDisposeTemplate.dispose()}disposeElement(e,t,i){i.toDisposeElement.clear(),i.actionBar.clear()}}let Xs=class extends Qs{static{Us=this}static{this.ID="quickpickitem"}constructor(e,t){super(e),this.themeService=t,this._itemsWithSeparatorsFrequency=new Map}get templateId(){return Us.ID}renderTemplate(e){const t=super.renderTemplate(e);return t.toDisposeTemplate.add(U.b2(t.checkbox,U.Bx.CHANGE,(e=>{t.element.checked=t.checkbox.checked}))),t}renderElement(e,t,i){const s=e.element;i.element=s,s.element=i.entry??void 0;const n=s.item;i.checkbox.checked=s.checked,i.toDisposeElement.add(s.onChecked((e=>i.checkbox.checked=e))),i.checkbox.disabled=s.checkboxDisabled;const{labelHighlights:r,descriptionHighlights:o,detailHighlights:a}=s;if(n.iconPath){const e=(0,Ds.HD)(this.themeService.getColorTheme().type)?n.iconPath.dark:n.iconPath.light??n.iconPath.dark,t=h.r.revive(e);i.icon.className="quick-input-list-icon",i.icon.style.backgroundImage=U.Tf(t)}else i.icon.style.backgroundImage="",i.icon.className=n.iconClass?`quick-input-list-icon ${n.iconClass}`:"";let l;!s.saneTooltip&&s.saneDescription&&(l={markdown:{value:s.saneDescription,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDescription});const c={matches:r||[],descriptionTitle:l,descriptionMatches:o||[],labelEscapeNewLines:!0};if(c.extraClasses=n.iconClasses,c.italic=n.italic,c.strikethrough=n.strikethrough,i.entry.classList.remove("quick-input-list-separator-as-item"),i.label.setLabel(s.saneLabel,s.saneDescription,c),i.keybinding.set(n.keybinding),s.saneDetail){let e;s.saneTooltip||(e={markdown:{value:s.saneDetail,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDetail}),i.detail.element.style.display="",i.detail.setLabel(s.saneDetail,void 0,{matches:a,title:e,labelEscapeNewLines:!0})}else i.detail.element.style.display="none";s.separator?.label?(i.separator.textContent=s.separator.label,i.separator.style.display="",this.addItemWithSeparator(s)):i.separator.style.display="none",i.entry.classList.toggle("quick-input-list-separator-border",!!s.separator);const d=n.buttons;d&&d.length?(i.actionBar.push(d.map(((e,t)=>ss(e,`id-${t}`,(()=>s.fireButtonTriggered({button:e,item:s.item}))))),{icon:!0,label:!1}),i.entry.classList.add("has-actions")):i.entry.classList.remove("has-actions")}disposeElement(e,t,i){this.removeItemWithSeparator(e.element),super.disposeElement(e,t,i)}isItemWithSeparatorVisible(e){return this._itemsWithSeparatorsFrequency.has(e)}addItemWithSeparator(e){this._itemsWithSeparatorsFrequency.set(e,(this._itemsWithSeparatorsFrequency.get(e)||0)+1)}removeItemWithSeparator(e){const t=this._itemsWithSeparatorsFrequency.get(e)||0;t>1?this._itemsWithSeparatorsFrequency.set(e,t-1):this._itemsWithSeparatorsFrequency.delete(e)}};Xs=Us=Ws([Vs(1,Z.Gy)],Xs);class Zs extends Qs{constructor(){super(...arguments),this._visibleSeparatorsFrequency=new Map}static{this.ID="quickpickseparator"}get templateId(){return Zs.ID}get visibleSeparators(){return[...this._visibleSeparatorsFrequency.keys()]}isSeparatorVisible(e){return this._visibleSeparatorsFrequency.has(e)}renderTemplate(e){const t=super.renderTemplate(e);return t.checkbox.style.display="none",t}renderElement(e,t,i){const s=e.element;i.element=s,s.element=i.entry??void 0,s.element.classList.toggle("focus-inside",!!s.focusInsideSeparator);const n=s.separator,{labelHighlights:r,descriptionHighlights:o,detailHighlights:a}=s;let l;i.icon.style.backgroundImage="",i.icon.className="",!s.saneTooltip&&s.saneDescription&&(l={markdown:{value:s.saneDescription,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDescription});const c={matches:r||[],descriptionTitle:l,descriptionMatches:o||[],labelEscapeNewLines:!0};if(i.entry.classList.add("quick-input-list-separator-as-item"),i.label.setLabel(s.saneLabel,s.saneDescription,c),s.saneDetail){let e;s.saneTooltip||(e={markdown:{value:s.saneDetail,supportThemeIcons:!0},markdownNotSupportedFallback:s.saneDetail}),i.detail.element.style.display="",i.detail.setLabel(s.saneDetail,void 0,{matches:a,title:e,labelEscapeNewLines:!0})}else i.detail.element.style.display="none";i.separator.style.display="none",i.entry.classList.add("quick-input-list-separator-border");const h=n.buttons;h&&h.length?(i.actionBar.push(h.map(((e,t)=>ss(e,`id-${t}`,(()=>s.fireSeparatorButtonTriggered({button:e,separator:s.separator}))))),{icon:!0,label:!1}),i.entry.classList.add("has-actions")):i.entry.classList.remove("has-actions"),this.addSeparator(s)}disposeElement(e,t,i){this.removeSeparator(e.element),this.isSeparatorVisible(e.element)||e.element.element?.classList.remove("focus-inside"),super.disposeElement(e,t,i)}addSeparator(e){this._visibleSeparatorsFrequency.set(e,(this._visibleSeparatorsFrequency.get(e)||0)+1)}removeSeparator(e){const t=this._visibleSeparatorsFrequency.get(e)||0;t>1?this._visibleSeparatorsFrequency.set(e,t-1):this._visibleSeparatorsFrequency.delete(e)}}let Js=class extends l.jG{constructor(e,t,i,s,n,r){super(),this.parent=e,this.hoverDelegate=t,this.linkOpenerDelegate=i,this.accessibilityService=r,this._onKeyDown=new Q.vl,this._onLeave=new Q.vl,this.onLeave=this._onLeave.event,this._visibleCountObservable=(0,Bs.FY)("VisibleCount",0),this.onChangedVisibleCount=Q.Jh.fromObservable(this._visibleCountObservable,this._store),this._allVisibleCheckedObservable=(0,Bs.FY)("AllVisibleChecked",!1),this.onChangedAllVisibleChecked=Q.Jh.fromObservable(this._allVisibleCheckedObservable,this._store),this._checkedCountObservable=(0,Bs.FY)("CheckedCount",0),this.onChangedCheckedCount=Q.Jh.fromObservable(this._checkedCountObservable,this._store),this._checkedElementsObservable=(0,Bs.Zh)({equalsFn:b.aI},new Array),this.onChangedCheckedElements=Q.Jh.fromObservable(this._checkedElementsObservable,this._store),this._onButtonTriggered=new Q.vl,this.onButtonTriggered=this._onButtonTriggered.event,this._onSeparatorButtonTriggered=new Q.vl,this.onSeparatorButtonTriggered=this._onSeparatorButtonTriggered.event,this._elementChecked=new Q.vl,this._elementCheckedEventBufferer=new Q.at,this._hasCheckboxes=!1,this._inputElements=new Array,this._elementTree=new Array,this._itemElements=new Array,this._elementDisposable=this._register(new l.Cm),this._matchOnDescription=!1,this._matchOnDetail=!1,this._matchOnLabel=!0,this._matchOnLabelMode="fuzzy",this._sortByLabel=!0,this._shouldLoop=!0,this._container=U.BC(this.parent,zs(".quick-input-list")),this._separatorRenderer=new Zs(t),this._itemRenderer=n.createInstance(Xs,t),this._tree=this._register(n.createInstance(Ns.zL,"QuickInput",this._container,new qs,[this._itemRenderer,this._separatorRenderer],{filter:{filter:e=>e.hidden?0:e instanceof Ys?2:1},sorter:{compare:(e,t)=>{if(!this.sortByLabel||!this._lastQueryString)return 0;return function(e,t,i){const s=e.labelHighlights||[],n=t.labelHighlights||[];if(s.length&&!n.length)return-1;if(!s.length&&n.length)return 1;if(0===s.length&&0===n.length)return 0;return Fs(e.saneSortLabel,t.saneSortLabel,i)}(e,t,this._lastQueryString.toLowerCase())}},accessibilityProvider:new $s,setRowLineHeight:!1,multipleSelectionSupport:!1,hideTwistiesOfChildlessElements:!0,renderIndentGuides:Hs.KP.None,findWidgetEnabled:!1,indent:0,horizontalScrolling:!1,allowNonCollapsibleParents:!0,alwaysConsumeMouseWheel:!0})),this._tree.getHTMLElement().id=s,this._registerListeners()}get onDidChangeFocus(){return Q.Jh.map(this._tree.onDidChangeFocus,(e=>e.elements.filter((e=>e instanceof js)).map((e=>e.item))),this._store)}get onDidChangeSelection(){return Q.Jh.map(this._tree.onDidChangeSelection,(e=>({items:e.elements.filter((e=>e instanceof js)).map((e=>e.item)),event:e.browserEvent})),this._store)}get displayed(){return"none"!==this._container.style.display}set displayed(e){this._container.style.display=e?"":"none"}get scrollTop(){return this._tree.scrollTop}set scrollTop(e){this._tree.scrollTop=e}get ariaLabel(){return this._tree.ariaLabel}set ariaLabel(e){this._tree.ariaLabel=e??""}set enabled(e){this._tree.getHTMLElement().style.pointerEvents=e?"":"none"}get matchOnDescription(){return this._matchOnDescription}set matchOnDescription(e){this._matchOnDescription=e}get matchOnDetail(){return this._matchOnDetail}set matchOnDetail(e){this._matchOnDetail=e}get matchOnLabel(){return this._matchOnLabel}set matchOnLabel(e){this._matchOnLabel=e}get matchOnLabelMode(){return this._matchOnLabelMode}set matchOnLabelMode(e){this._matchOnLabelMode=e}get sortByLabel(){return this._sortByLabel}set sortByLabel(e){this._sortByLabel=e}get shouldLoop(){return this._shouldLoop}set shouldLoop(e){this._shouldLoop=e}_registerListeners(){this._registerOnKeyDown(),this._registerOnContainerClick(),this._registerOnMouseMiddleClick(),this._registerOnTreeModelChanged(),this._registerOnElementChecked(),this._registerOnContextMenu(),this._registerHoverListeners(),this._registerSelectionChangeListener(),this._registerSeparatorActionShowingListeners()}_registerOnKeyDown(){this._register(this._tree.onKeyDown((e=>{const t=new Xe.Z(e);if(10===t.keyCode)this.toggleCheckbox();this._onKeyDown.fire(t)})))}_registerOnContainerClick(){this._register(U.ko(this._container,U.Bx.CLICK,(e=>{(e.x||e.y)&&this._onLeave.fire()})))}_registerOnMouseMiddleClick(){this._register(U.ko(this._container,U.Bx.AUXCLICK,(e=>{1===e.button&&this._onLeave.fire()})))}_registerOnTreeModelChanged(){this._register(this._tree.onDidChangeModel((()=>{const e=this._itemElements.filter((e=>!e.hidden)).length;this._visibleCountObservable.set(e,void 0),this._hasCheckboxes&&this._updateCheckedObservables()})))}_registerOnElementChecked(){this._register(this._elementCheckedEventBufferer.wrapEvent(this._elementChecked.event,((e,t)=>t))((e=>this._updateCheckedObservables())))}_registerOnContextMenu(){this._register(this._tree.onContextMenu((e=>{e.element&&(e.browserEvent.preventDefault(),this._tree.setSelection([e.element]))})))}_registerHoverListeners(){const e=this._register(new m.Th(this.hoverDelegate.delay));this._register(this._tree.onMouseOver((async t=>{if(U.nY(t.browserEvent.target))e.cancel();else if(U.nY(t.browserEvent.relatedTarget)||!U.QX(t.browserEvent.relatedTarget,t.element?.element))try{await e.trigger((async()=>{t.element instanceof js&&this.showHover(t.element)}))}catch(t){if(!(0,v.MB)(t))throw t}}))),this._register(this._tree.onMouseOut((t=>{U.QX(t.browserEvent.relatedTarget,t.element?.element)||e.cancel()})))}_registerSeparatorActionShowingListeners(){this._register(this._tree.onDidChangeFocus((e=>{const t=e.elements[0]?this._tree.getParentElement(e.elements[0]):null;for(const i of this._separatorRenderer.visibleSeparators){const e=i===t;!!(i.focusInsideSeparator&Ks.ACTIVE_ITEM)!==e&&(e?i.focusInsideSeparator|=Ks.ACTIVE_ITEM:i.focusInsideSeparator&=~Ks.ACTIVE_ITEM,this._tree.rerender(i))}}))),this._register(this._tree.onMouseOver((e=>{const t=e.element?this._tree.getParentElement(e.element):null;for(const i of this._separatorRenderer.visibleSeparators){if(i!==t)continue;!!(i.focusInsideSeparator&Ks.MOUSE_HOVER)||(i.focusInsideSeparator|=Ks.MOUSE_HOVER,this._tree.rerender(i))}}))),this._register(this._tree.onMouseOut((e=>{const t=e.element?this._tree.getParentElement(e.element):null;for(const i of this._separatorRenderer.visibleSeparators){if(i!==t)continue;!!(i.focusInsideSeparator&Ks.MOUSE_HOVER)&&(i.focusInsideSeparator&=~Ks.MOUSE_HOVER,this._tree.rerender(i))}})))}_registerSelectionChangeListener(){this._register(this._tree.onDidChangeSelection((e=>{const t=e.elements.filter((e=>e instanceof js));t.length!==e.elements.length&&(1===e.elements.length&&e.elements[0]instanceof Ys&&(this._tree.setFocus([e.elements[0].children[0]]),this._tree.reveal(e.elements[0],0)),this._tree.setSelection(t))})))}setAllVisibleChecked(e){this._elementCheckedEventBufferer.bufferEvents((()=>{this._itemElements.forEach((t=>{t.hidden||t.checkboxDisabled||(t.checked=e)}))}))}setElements(e){let t;this._elementDisposable.clear(),this._lastQueryString=void 0,this._inputElements=e,this._hasCheckboxes=this.parent.classList.contains("show-checkboxes"),this._itemElements=new Array,this._elementTree=e.reduce(((i,s,n)=>{let r;if("separator"===s.type){if(!s.buttons)return i;t=new Ys(n,(e=>this._onSeparatorButtonTriggered.fire(e)),s),r=t}else{const o=n>0?e[n-1]:void 0;let a;o&&"separator"===o.type&&!o.buttons&&(t=void 0,a=o);const l=new js(n,this._hasCheckboxes,(e=>this._onButtonTriggered.fire(e)),this._elementChecked,s,a);if(this._itemElements.push(l),t)return t.children.push(l),i;r=l}return i.push(r),i}),new Array),this._setElementsToTree(this._elementTree),this.accessibilityService.isScreenReaderOptimized()&&setTimeout((()=>{const e=this._tree.getHTMLElement().querySelector(".monaco-list-row.focused"),t=e?.parentNode;if(e&&t){const i=e.nextSibling;e.remove(),t.insertBefore(e,i)}}),0)}setFocusedElements(e){const t=e.map((e=>this._itemElements.find((t=>t.item===e)))).filter((e=>!!e)).filter((e=>!e.hidden));if(this._tree.setFocus(t),e.length>0){const e=this._tree.getFocus()[0];e&&this._tree.reveal(e)}}getActiveDescendant(){return this._tree.getHTMLElement().getAttribute("aria-activedescendant")}setSelectedElements(e){const t=e.map((e=>this._itemElements.find((t=>t.item===e)))).filter((e=>!!e));this._tree.setSelection(t)}getCheckedElements(){return this._itemElements.filter((e=>e.checked)).map((e=>e.item))}setCheckedElements(e){this._elementCheckedEventBufferer.bufferEvents((()=>{const t=new Set;for(const i of e)t.add(i);for(const e of this._itemElements)e.checked=t.has(e.item)}))}focus(e){if(this._itemElements.length)switch(e===zi.Fp.Second&&this._itemElements.length<2&&(e=zi.Fp.First),e){case zi.Fp.First:this._tree.scrollTop=0,this._tree.focusFirst(void 0,(e=>e.element instanceof js));break;case zi.Fp.Second:{this._tree.scrollTop=0;let e=!1;this._tree.focusFirst(void 0,(t=>t.element instanceof js&&(!!e||(e=!e,!1))));break}case zi.Fp.Last:this._tree.scrollTop=this._tree.scrollHeight,this._tree.focusLast(void 0,(e=>e.element instanceof js));break;case zi.Fp.Next:{const e=this._tree.getFocus();this._tree.focusNext(void 0,this._shouldLoop,void 0,(e=>e.element instanceof js&&(this._tree.reveal(e.element),!0)));const t=this._tree.getFocus();e.length&&e[0]===t[0]&&e[0]===this._itemElements[this._itemElements.length-1]&&this._onLeave.fire();break}case zi.Fp.Previous:{const e=this._tree.getFocus();this._tree.focusPrevious(void 0,this._shouldLoop,void 0,(e=>{if(!(e.element instanceof js))return!1;const t=this._tree.getParentElement(e.element);return null===t||t.children[0]!==e.element?this._tree.reveal(e.element):this._tree.reveal(t),!0}));const t=this._tree.getFocus();e.length&&e[0]===t[0]&&e[0]===this._itemElements[0]&&this._onLeave.fire();break}case zi.Fp.NextPage:this._tree.focusNextPage(void 0,(e=>e.element instanceof js&&(this._tree.reveal(e.element),!0)));break;case zi.Fp.PreviousPage:this._tree.focusPreviousPage(void 0,(e=>{if(!(e.element instanceof js))return!1;const t=this._tree.getParentElement(e.element);return null===t||t.children[0]!==e.element?this._tree.reveal(e.element):this._tree.reveal(t),!0}));break;case zi.Fp.NextSeparator:{let e=!1;const t=this._tree.getFocus()[0];this._tree.focusNext(void 0,!0,void 0,(t=>{if(e)return!0;if(t.element instanceof Ys)e=!0,this._separatorRenderer.isSeparatorVisible(t.element)?this._tree.reveal(t.element.children[0]):this._tree.reveal(t.element,0);else if(t.element instanceof js){if(t.element.separator)return this._itemRenderer.isItemWithSeparatorVisible(t.element)?this._tree.reveal(t.element):this._tree.reveal(t.element,0),!0;if(t.element===this._elementTree[0])return this._tree.reveal(t.element,0),!0}return!1}));t===this._tree.getFocus()[0]&&(this._tree.scrollTop=this._tree.scrollHeight,this._tree.focusLast(void 0,(e=>e.element instanceof js)));break}case zi.Fp.PreviousSeparator:{let e,t=!!this._tree.getFocus()[0]?.separator;this._tree.focusPrevious(void 0,!0,void 0,(i=>{if(i.element instanceof Ys)t?e||(this._separatorRenderer.isSeparatorVisible(i.element)?this._tree.reveal(i.element):this._tree.reveal(i.element,0),e=i.element.children[0]):t=!0;else if(i.element instanceof js&&!e)if(i.element.separator)this._itemRenderer.isItemWithSeparatorVisible(i.element)?this._tree.reveal(i.element):this._tree.reveal(i.element,0),e=i.element;else if(i.element===this._elementTree[0])return this._tree.reveal(i.element,0),!0;return!1})),e&&this._tree.setFocus([e]);break}}}clearFocus(){this._tree.setFocus([])}domFocus(){this._tree.domFocus()}layout(e){this._tree.getHTMLElement().style.maxHeight=e?44*Math.floor(e/44)+6+"px":"",this._tree.layout()}filter(e){if(this._lastQueryString=e,!(this._sortByLabel||this._matchOnLabel||this._matchOnDescription||this._matchOnDetail))return this._tree.layout(),!1;const t=e;if((e=e.trim())&&(this.matchOnLabel||this.matchOnDescription||this.matchOnDetail)){let i;this._itemElements.forEach((s=>{let n;n="fuzzy"===this.matchOnLabelMode?this.matchOnLabel?(0,pi.pz)(e,(0,pi._k)(s.saneLabel))??void 0:void 0:this.matchOnLabel?function(e,t){const{text:i,iconOffsets:s}=t;if(!s||0===s.length)return en(e,i);const n=(0,c.NB)(i," "),r=i.length-n.length,o=en(e,n);if(o)for(const a of o){const e=s[a.start+r]+r;a.start+=e,a.end+=e}return o}(t,(0,pi._k)(s.saneLabel))??void 0:void 0;const r=this.matchOnDescription?(0,pi.pz)(e,(0,pi._k)(s.saneDescription||""))??void 0:void 0,o=this.matchOnDetail?(0,pi.pz)(e,(0,pi._k)(s.saneDetail||""))??void 0:void 0;if(n||r||o?(s.labelHighlights=n,s.descriptionHighlights=r,s.detailHighlights=o,s.hidden=!1):(s.labelHighlights=void 0,s.descriptionHighlights=void 0,s.detailHighlights=void 0,s.hidden=!s.item||!s.item.alwaysShow),s.item?s.separator=void 0:s.separator&&(s.hidden=!0),!this.sortByLabel){const e=s.index&&this._inputElements[s.index-1]||void 0;"separator"!==e?.type||e.buttons||(i=e),i&&!s.hidden&&(s.separator=i,i=void 0)}}))}else this._itemElements.forEach((e=>{e.labelHighlights=void 0,e.descriptionHighlights=void 0,e.detailHighlights=void 0,e.hidden=!1;const t=e.index&&this._inputElements[e.index-1];e.item&&(e.separator=t&&"separator"===t.type&&!t.buttons?t:void 0)}));return this._setElementsToTree(this._sortByLabel&&e?this._itemElements:this._elementTree),this._tree.layout(),!0}toggleCheckbox(){this._elementCheckedEventBufferer.bufferEvents((()=>{const e=this._tree.getFocus().filter((e=>e instanceof js)),t=this._allVisibleChecked(e);for(const i of e)i.checkboxDisabled||(i.checked=!t)}))}style(e){this._tree.style(e)}toggleHover(){const e=this._tree.getFocus()[0];if(!e?.saneTooltip||!(e instanceof js))return;if(this._lastHover&&!this._lastHover.isDisposed)return void this._lastHover.dispose();this.showHover(e);const t=new l.Cm;t.add(this._tree.onDidChangeFocus((e=>{e.elements[0]instanceof js&&this.showHover(e.elements[0])}))),this._lastHover&&t.add(this._lastHover),this._elementDisposable.add(t)}_setElementsToTree(e){const t=new Array;for(const i of e)i instanceof Ys?t.push({element:i,collapsible:!1,collapsed:!1,children:i.children.map((e=>({element:e,collapsible:!1,collapsed:!1})))}):t.push({element:i,collapsible:!1,collapsed:!1});this._tree.setChildren(null,t)}_allVisibleChecked(e,t=!0){for(let i=0,s=e.length;i{this._allVisibleCheckedObservable.set(this._allVisibleChecked(this._itemElements,!1),e);const t=this._itemElements.filter((e=>e.checked)).length;this._checkedCountObservable.set(t,e),this._checkedElementsObservable.set(this.getCheckedElements(),e)}))}showHover(e){this._lastHover&&!this._lastHover.isDisposed&&(this.hoverDelegate.onDidHideHover?.(),this._lastHover?.dispose()),e.element&&e.saneTooltip&&(this._lastHover=this.hoverDelegate.showHover({content:e.saneTooltip,target:e.element,linkHandler:e=>{this.linkOpenerDelegate(e)},appearance:{showPointer:!0},container:this._container,position:{hoverPosition:1}},!1))}};function en(e,t){const i=t.toLowerCase().indexOf(e.toLowerCase());return-1!==i?[{start:i,end:i+e.length}]:null}Ws([Xi.B],Js.prototype,"onDidChangeFocus",null),Ws([Xi.B],Js.prototype,"onDidChangeSelection",null),Js=Ws([Vs(4,ae._Y),Vs(5,Ve.j)],Js);var tn=i(28290);const sn={weight:200,when:ie.M$.and(ie.M$.equals(hs,"quickPick"),cs),metadata:{description:(0,E.kg)("quickPick","Used while in the context of the quick pick. If you change one keybinding for this command, you should change all of the other keybindings (modifier variants) of this command as well.")}};function nn(e,t={}){Wt.f.registerCommandAndKeybindingRule({...sn,...e,secondary:on(e.primary,e.secondary??[],t)})}const rn=We.zx?256:2048;function on(e,t,i={}){return i.withAltMod&&t.push(512+e),i.withCtrlMod&&(t.push(rn+e),i.withAltMod&&t.push(512+rn+e)),i.withCmdMod&&We.zx&&(t.push(2048+e),i.withCtrlMod&&t.push(2304+e),i.withAltMod&&(t.push(2560+e),i.withCtrlMod&&t.push(2816+e))),t}function an(e,t){return i=>{const s=i.get(zi.GK).currentQuickInput;if(s)return t&&s.quickNavigate?s.focus(t):s.focus(e)}}nn({id:"quickInput.pageNext",primary:12,handler:an(zi.Fp.NextPage)},{withAltMod:!0,withCtrlMod:!0,withCmdMod:!0}),nn({id:"quickInput.pagePrevious",primary:11,handler:an(zi.Fp.PreviousPage)},{withAltMod:!0,withCtrlMod:!0,withCmdMod:!0}),nn({id:"quickInput.first",primary:rn+14,handler:an(zi.Fp.First)},{withAltMod:!0,withCmdMod:!0}),nn({id:"quickInput.last",primary:rn+13,handler:an(zi.Fp.Last)},{withAltMod:!0,withCmdMod:!0}),nn({id:"quickInput.next",primary:18,handler:an(zi.Fp.Next)},{withCtrlMod:!0}),nn({id:"quickInput.previous",primary:16,handler:an(zi.Fp.Previous)},{withCtrlMod:!0});const ln=(0,E.kg)("quickInput.nextSeparatorWithQuickAccessFallback","If we're in quick access mode, this will navigate to the next item. If we are not in quick access mode, this will navigate to the next separator."),cn=(0,E.kg)("quickInput.previousSeparatorWithQuickAccessFallback","If we're in quick access mode, this will navigate to the previous item. If we are not in quick access mode, this will navigate to the previous separator.");We.zx?(nn({id:"quickInput.nextSeparatorWithQuickAccessFallback",primary:2066,handler:an(zi.Fp.NextSeparator,zi.Fp.Next),metadata:{description:ln}}),nn({id:"quickInput.nextSeparator",primary:2578,secondary:[2322],handler:an(zi.Fp.NextSeparator)},{withCtrlMod:!0}),nn({id:"quickInput.previousSeparatorWithQuickAccessFallback",primary:2064,handler:an(zi.Fp.PreviousSeparator,zi.Fp.Previous),metadata:{description:cn}}),nn({id:"quickInput.previousSeparator",primary:2576,secondary:[2320],handler:an(zi.Fp.PreviousSeparator)},{withCtrlMod:!0})):(nn({id:"quickInput.nextSeparatorWithQuickAccessFallback",primary:530,handler:an(zi.Fp.NextSeparator,zi.Fp.Next),metadata:{description:ln}}),nn({id:"quickInput.nextSeparator",primary:2578,handler:an(zi.Fp.NextSeparator)}),nn({id:"quickInput.previousSeparatorWithQuickAccessFallback",primary:528,handler:an(zi.Fp.PreviousSeparator,zi.Fp.Previous),metadata:{description:cn}}),nn({id:"quickInput.previousSeparator",primary:2576,handler:an(zi.Fp.PreviousSeparator)})),nn({id:"quickInput.acceptInBackground",when:ie.M$.and(sn.when,ie.M$.or(tn.J7.negate(),ps)),primary:17,weight:250,handler:e=>{const t=e.get(zi.GK).currentQuickInput;t?.accept(!0)}},{withAltMod:!0,withCtrlMod:!0,withCmdMod:!0});var hn,dn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},un=function(e,t){return function(i,s){t(i,s,e)}};const gn=U.$;let pn=class extends l.jG{static{hn=this}static{this.MAX_WIDTH=600}get currentQuickInput(){return this.controller??void 0}get container(){return this._container}constructor(e,t,i,s){super(),this.options=e,this.layoutService=t,this.instantiationService=i,this.contextKeyService=s,this.enabled=!0,this.onDidAcceptEmitter=this._register(new Q.vl),this.onDidCustomEmitter=this._register(new Q.vl),this.onDidTriggerButtonEmitter=this._register(new Q.vl),this.keyMods={ctrlCmd:!1,alt:!1},this.controller=null,this.onShowEmitter=this._register(new Q.vl),this.onShow=this.onShowEmitter.event,this.onHideEmitter=this._register(new Q.vl),this.onHide=this.onHideEmitter.event,this.inQuickInputContext=ls.bindTo(this.contextKeyService),this.quickInputTypeContext=ds.bindTo(this.contextKeyService),this.endOfQuickInputBoxContext=gs.bindTo(this.contextKeyService),this.idPrefix=e.idPrefix,this._container=e.container,this.styles=e.styles,this._register(Q.Jh.runAndSubscribe(U.Iv,(({window:e,disposables:t})=>this.registerKeyModsListeners(e,t)),{window:a.G,disposables:this._store})),this._register(U.q3((e=>{this.ui&&U.zk(this.ui.container)===e&&(this.reparentUI(this.layoutService.mainContainer),this.layout(this.layoutService.mainContainerDimension,this.layoutService.mainContainerOffset.quickPickTop))})))}registerKeyModsListeners(e,t){const i=e=>{this.keyMods.ctrlCmd=e.ctrlKey||e.metaKey,this.keyMods.alt=e.altKey};for(const s of[U.Bx.KEY_DOWN,U.Bx.KEY_UP,U.Bx.MOUSE_DOWN])t.add(U.ko(e,s,i,!0))}getUI(e){if(this.ui)return e&&U.zk(this._container)!==U.zk(this.layoutService.activeContainer)&&(this.reparentUI(this.layoutService.activeContainer),this.layout(this.layoutService.activeContainerDimension,this.layoutService.activeContainerOffset.quickPickTop)),this.ui;const t=U.BC(this._container,gn(".quick-input-widget.show-file-icons"));t.tabIndex=-1,t.style.display="none";const i=U.li(t),s=U.BC(t,gn(".quick-input-titlebar")),n=this._register(new li.E(s,{hoverDelegate:this.options.hoverDelegate}));n.domNode.classList.add("quick-input-left-action-bar");const r=U.BC(s,gn(".quick-input-title")),o=this._register(new li.E(s,{hoverDelegate:this.options.hoverDelegate}));o.domNode.classList.add("quick-input-right-action-bar");const a=U.BC(t,gn(".quick-input-header")),l=U.BC(a,gn("input.quick-input-check-all"));l.type="checkbox",l.setAttribute("aria-label",(0,E.kg)("quickInput.checkAll","Toggle all checkboxes")),this._register(U.b2(l,U.Bx.CHANGE,(e=>{const t=l.checked;x.setAllVisibleChecked(t)}))),this._register(U.ko(l,U.Bx.CLICK,(e=>{(e.x||e.y)&&u.setFocus()})));const c=U.BC(a,gn(".quick-input-description")),h=U.BC(a,gn(".quick-input-and-message")),d=U.BC(h,gn(".quick-input-filter")),u=this._register(new As(d,this.styles.inputBox,this.styles.toggle));u.setAttribute("aria-describedby",`${this.idPrefix}message`);const g=U.BC(d,gn(".quick-input-visible-count"));g.setAttribute("aria-live","polite"),g.setAttribute("aria-atomic","true");const p=new Es.x(g,{countFormat:(0,E.kg)({key:"quickInput.visibleCount",comment:["This tells the user how many items are shown in a list of items to select from. The items can be anything. Currently not visible, but read by screen readers."]},"{0} Results")},this.styles.countBadge),m=U.BC(d,gn(".quick-input-count"));m.setAttribute("aria-live","polite");const f=new Es.x(m,{countFormat:(0,E.kg)({key:"quickInput.countSelected",comment:["This tells the user how many items are selected in a list of items to select from. The items can be anything."]},"{0} Selected")},this.styles.countBadge),_=this._register(new li.E(a,{hoverDelegate:this.options.hoverDelegate}));_.domNode.classList.add("quick-input-inline-action-bar");const v=U.BC(a,gn(".quick-input-action")),C=this._register(new bs.$(v,this.styles.button));C.label=(0,E.kg)("ok","OK"),this._register(C.onDidClick((e=>{this.onDidAcceptEmitter.fire()})));const b=U.BC(a,gn(".quick-input-action")),S=this._register(new bs.$(b,{...this.styles.button,supportIcons:!0}));S.label=(0,E.kg)("custom","Custom"),this._register(S.onDidClick((e=>{this.onDidCustomEmitter.fire()})));const y=U.BC(h,gn(`#${this.idPrefix}message.quick-input-message`)),w=this._register(new Ts(t,this.styles.progressBar));w.getContainer().classList.add("quick-input-progress");const L=U.BC(t,gn(".quick-input-html-widget"));L.tabIndex=-1;const R=U.BC(t,gn(".quick-input-description")),T=this.idPrefix+"list",x=this._register(this.instantiationService.createInstance(Js,t,this.options.hoverDelegate,this.options.linkOpenerDelegate,T));u.setAttribute("aria-controls",T),this._register(x.onDidChangeFocus((()=>{u.setAttribute("aria-activedescendant",x.getActiveDescendant()??"")}))),this._register(x.onChangedAllVisibleChecked((e=>{l.checked=e}))),this._register(x.onChangedVisibleCount((e=>{p.setCount(e)}))),this._register(x.onChangedCheckedCount((e=>{f.setCount(e)}))),this._register(x.onLeave((()=>{setTimeout((()=>{this.controller&&(u.setFocus(),this.controller instanceof _s&&this.controller.canSelectMany&&x.clearFocus())}),0)})));const k=U.w5(t);return this._register(k),this._register(U.ko(t,U.Bx.FOCUS,(e=>{const t=this.getUI();if(U.QX(e.relatedTarget,t.inputContainer)){const e=t.inputBox.isSelectionAtEnd();this.endOfQuickInputBoxContext.get()!==e&&this.endOfQuickInputBoxContext.set(e)}U.QX(e.relatedTarget,t.container)||(this.inQuickInputContext.set(!0),this.previousFocusElement=U.sb(e.relatedTarget)?e.relatedTarget:void 0)}),!0)),this._register(k.onDidBlur((()=>{this.getUI().ignoreFocusOut||this.options.ignoreFocusOut()||this.hide(zi.kF.Blur),this.inQuickInputContext.set(!1),this.endOfQuickInputBoxContext.set(!1),this.previousFocusElement=void 0}))),this._register(u.onKeyDown((e=>{const t=this.getUI().inputBox.isSelectionAtEnd();this.endOfQuickInputBoxContext.get()!==t&&this.endOfQuickInputBoxContext.set(t)}))),this._register(U.ko(t,U.Bx.FOCUS,(e=>{u.setFocus()}))),this._register(U.b2(t,U.Bx.KEY_DOWN,(e=>{if(!U.QX(e.target,L))switch(e.keyCode){case 3:U.fs.stop(e,!0),this.enabled&&this.onDidAcceptEmitter.fire();break;case 9:U.fs.stop(e,!0),this.hide(zi.kF.Gesture);break;case 2:if(!e.altKey&&!e.ctrlKey&&!e.metaKey){const i=[".quick-input-list .monaco-action-bar .always-visible",".quick-input-list-entry:hover .monaco-action-bar",".monaco-list-row.focused .monaco-action-bar"];if(t.classList.contains("show-checkboxes")?i.push("input"):i.push("input[type=text]"),this.getUI().list.displayed&&i.push(".monaco-list"),this.getUI().message&&i.push(".quick-input-message a"),this.getUI().widget){if(U.QX(e.target,this.getUI().widget))break;i.push(".quick-input-html-widget")}const s=t.querySelectorAll(i.join(", "));e.shiftKey&&e.target===s[0]?(U.fs.stop(e,!0),x.clearFocus()):!e.shiftKey&&U.QX(e.target,s[s.length-1])&&(U.fs.stop(e,!0),s[0].focus())}break;case 10:e.ctrlKey&&(U.fs.stop(e,!0),this.getUI().list.toggleHover())}}))),this.ui={container:t,styleSheet:i,leftActionBar:n,titleBar:s,title:r,description1:R,description2:c,widget:L,rightActionBar:o,inlineActionBar:_,checkAll:l,inputContainer:h,filterContainer:d,inputBox:u,visibleCountContainer:g,visibleCount:p,countContainer:m,count:f,okContainer:v,ok:C,message:y,customButtonContainer:b,customButton:S,list:x,progressBar:w,onDidAccept:this.onDidAcceptEmitter.event,onDidCustom:this.onDidCustomEmitter.event,onDidTriggerButton:this.onDidTriggerButtonEmitter.event,ignoreFocusOut:!1,keyMods:this.keyMods,show:e=>this.show(e),hide:()=>this.hide(),setVisibilities:e=>this.setVisibilities(e),setEnabled:e=>this.setEnabled(e),setContextKey:e=>this.options.setContextKey(e),linkOpenerDelegate:e=>this.options.linkOpenerDelegate(e)},this.updateStyles(),this.ui}reparentUI(e){this.ui&&(this._container=e,U.BC(this._container,this.ui.container))}pick(e,t={},i=at.XO.None){return new Promise(((s,n)=>{let r=e=>{r=s,t.onKeyMods?.(o.keyMods),s(e)};if(i.isCancellationRequested)return void r(void 0);const o=this.createQuickPick({useSeparators:!0});let a;const c=[o,o.onDidAccept((()=>{if(o.canSelectMany)r(o.selectedItems.slice()),o.hide();else{const e=o.activeItems[0];e&&(r(e),o.hide())}})),o.onDidChangeActive((e=>{const i=e[0];i&&t.onDidFocus&&t.onDidFocus(i)})),o.onDidChangeSelection((e=>{if(!o.canSelectMany){const t=e[0];t&&(r(t),o.hide())}})),o.onDidTriggerItemButton((e=>t.onDidTriggerItemButton&&t.onDidTriggerItemButton({...e,removeItem:()=>{const t=o.items.indexOf(e.item);if(-1!==t){const e=o.items.slice(),i=e.splice(t,1),s=o.activeItems.filter((e=>e!==i[0])),n=o.keepScrollPosition;o.keepScrollPosition=!0,o.items=e,s&&(o.activeItems=s),o.keepScrollPosition=n}}}))),o.onDidTriggerSeparatorButton((e=>t.onDidTriggerSeparatorButton?.(e))),o.onDidChangeValue((e=>{!a||e||1===o.activeItems.length&&o.activeItems[0]===a||(o.activeItems=[a])})),i.onCancellationRequested((()=>{o.hide()})),o.onDidHide((()=>{(0,l.AS)(c),r(void 0)}))];o.title=t.title,t.value&&(o.value=t.value),o.canSelectMany=!!t.canPickMany,o.placeholder=t.placeHolder,o.ignoreFocusOut=!!t.ignoreFocusLost,o.matchOnDescription=!!t.matchOnDescription,o.matchOnDetail=!!t.matchOnDetail,o.matchOnLabel=void 0===t.matchOnLabel||t.matchOnLabel,o.quickNavigate=t.quickNavigate,o.hideInput=!!t.hideInput,o.contextKey=t.contextKey,o.busy=!0,Promise.all([e,t.activeItem]).then((([e,t])=>{a=t,o.busy=!1,o.items=e,o.canSelectMany&&(o.selectedItems=e.filter((e=>"separator"!==e.type&&e.picked))),a&&(o.activeItems=[a])})),o.show(),Promise.resolve(e).then(void 0,(e=>{n(e),o.hide()}))}))}createQuickPick(e={useSeparators:!1}){const t=this.getUI(!0);return new _s(t)}createInputBox(){const e=this.getUI(!0);return new vs(e)}show(e){const t=this.getUI(!0);this.onShowEmitter.fire();const i=this.controller;this.controller=e,i?.didHide(),this.setEnabled(!0),t.leftActionBar.clear(),t.title.textContent="",t.description1.textContent="",t.description2.textContent="",U.Ln(t.widget),t.rightActionBar.clear(),t.inlineActionBar.clear(),t.checkAll.checked=!1,t.inputBox.placeholder="",t.inputBox.password=!1,t.inputBox.showDecoration(ge.A.Ignore),t.visibleCount.setCount(0),t.count.setCount(0),U.Ln(t.message),t.progressBar.stop(),t.list.setElements([]),t.list.matchOnDescription=!1,t.list.matchOnDetail=!1,t.list.matchOnLabel=!0,t.list.sortByLabel=!0,t.ignoreFocusOut=!1,t.inputBox.toggles=void 0;const s=this.options.backKeybindingLabel();ms.tooltip=s?(0,E.kg)("quickInput.backWithKeybinding","Back ({0})",s):(0,E.kg)("quickInput.back","Back"),t.container.style.display="",this.updateLayout(),t.inputBox.setFocus(),this.quickInputTypeContext.set(e.type)}isVisible(){return!!this.ui&&"none"!==this.ui.container.style.display}setVisibilities(e){const t=this.getUI();t.title.style.display=e.title?"":"none",t.description1.style.display=e.description&&(e.inputBox||e.checkAll)?"":"none",t.description2.style.display=!e.description||e.inputBox||e.checkAll?"none":"",t.checkAll.style.display=e.checkAll?"":"none",t.inputContainer.style.display=e.inputBox?"":"none",t.filterContainer.style.display=e.inputBox?"":"none",t.visibleCountContainer.style.display=e.visibleCount?"":"none",t.countContainer.style.display=e.count?"":"none",t.okContainer.style.display=e.ok?"":"none",t.customButtonContainer.style.display=e.customButton?"":"none",t.message.style.display=e.message?"":"none",t.progressBar.getContainer().style.display=e.progressBar?"":"none",t.list.displayed=!!e.list,t.container.classList.toggle("show-checkboxes",!!e.checkBox),t.container.classList.toggle("hidden-input",!e.inputBox&&!e.description),this.updateLayout()}setEnabled(e){if(e!==this.enabled){this.enabled=e;for(const t of this.getUI().leftActionBar.viewItems)t.action.enabled=e;for(const t of this.getUI().rightActionBar.viewItems)t.action.enabled=e;this.getUI().checkAll.disabled=!e,this.getUI().inputBox.enabled=e,this.getUI().ok.enabled=e,this.getUI().list.enabled=e}}hide(e){const t=this.controller;if(!t)return;t.willHide(e);const i=this.ui?.container,s=i&&!U.nR(i);if(this.controller=null,this.onHideEmitter.fire(),i&&(i.style.display="none"),!s){let e=this.previousFocusElement;for(;e&&!e.offsetParent;)e=e.parentElement??void 0;e?.offsetParent?(e.focus(),this.previousFocusElement=void 0):this.options.returnFocus()}t.didHide(e)}layout(e,t){this.dimension=e,this.titleBarOffset=t,this.updateLayout()}updateLayout(){if(this.ui&&this.isVisible()){this.ui.container.style.top=`${this.titleBarOffset}px`;const e=this.ui.container.style,t=Math.min(.62*this.dimension.width,hn.MAX_WIDTH);e.width=t+"px",e.marginLeft="-"+t/2+"px",this.ui.inputBox.layout(),this.ui.list.layout(this.dimension&&.4*this.dimension.height)}}applyStyles(e){this.styles=e,this.updateStyles()}updateStyles(){if(this.ui){const{quickInputTitleBackground:e,quickInputBackground:t,quickInputForeground:i,widgetBorder:s,widgetShadow:n}=this.styles.widget;this.ui.titleBar.style.backgroundColor=e??"",this.ui.container.style.backgroundColor=t??"",this.ui.container.style.color=i??"",this.ui.container.style.border=s?`1px solid ${s}`:"",this.ui.container.style.boxShadow=n?`0 0 8px 2px ${n}`:"",this.ui.list.style(this.styles.list);const r=[];this.styles.pickerGroup.pickerGroupBorder&&r.push(`.quick-input-list .quick-input-list-entry { border-top-color: ${this.styles.pickerGroup.pickerGroupBorder}; }`),this.styles.pickerGroup.pickerGroupForeground&&r.push(`.quick-input-list .quick-input-list-separator { color: ${this.styles.pickerGroup.pickerGroupForeground}; }`),this.styles.pickerGroup.pickerGroupForeground&&r.push(".quick-input-list .quick-input-list-separator-as-item { color: var(--vscode-descriptionForeground); }"),(this.styles.keybindingLabel.keybindingLabelBackground||this.styles.keybindingLabel.keybindingLabelBorder||this.styles.keybindingLabel.keybindingLabelBottomBorder||this.styles.keybindingLabel.keybindingLabelShadow||this.styles.keybindingLabel.keybindingLabelForeground)&&(r.push(".quick-input-list .monaco-keybinding > .monaco-keybinding-key {"),this.styles.keybindingLabel.keybindingLabelBackground&&r.push(`background-color: ${this.styles.keybindingLabel.keybindingLabelBackground};`),this.styles.keybindingLabel.keybindingLabelBorder&&r.push(`border-color: ${this.styles.keybindingLabel.keybindingLabelBorder};`),this.styles.keybindingLabel.keybindingLabelBottomBorder&&r.push(`border-bottom-color: ${this.styles.keybindingLabel.keybindingLabelBottomBorder};`),this.styles.keybindingLabel.keybindingLabelShadow&&r.push(`box-shadow: inset 0 -1px 0 ${this.styles.keybindingLabel.keybindingLabelShadow};`),this.styles.keybindingLabel.keybindingLabelForeground&&r.push(`color: ${this.styles.keybindingLabel.keybindingLabelForeground};`),r.push("}"));const o=r.join("\n");o!==this.ui.styleSheet.textContent&&(this.ui.styleSheet.textContent=o)}}};pn=hn=dn([un(1,le),un(2,ae._Y),un(3,ie.fN)],pn);var mn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},fn=function(e,t){return function(i,s){t(i,s,e)}};let _n=class extends Z.lR{get controller(){return this._controller||(this._controller=this._register(this.createController())),this._controller}get hasController(){return!!this._controller}get currentQuickInput(){return this.controller.currentQuickInput}get quickAccess(){return this._quickAccess||(this._quickAccess=this._register(this.instantiationService.createInstance(Ki))),this._quickAccess}constructor(e,t,i,s,n){super(i),this.instantiationService=e,this.contextKeyService=t,this.layoutService=s,this.configurationService=n,this._onShow=this._register(new Q.vl),this._onHide=this._register(new Q.vl),this.contexts=new Map}createController(e=this.layoutService,t){const i={idPrefix:"quickInput_",container:e.activeContainer,ignoreFocusOut:()=>!1,backKeybindingLabel:()=>{},setContextKey:e=>this.setContextKey(e),linkOpenerDelegate:e=>{this.instantiationService.invokeFunction((t=>{t.get(Ue.C).open(e,{allowCommands:!0,fromUserGesture:!0})}))},returnFocus:()=>e.focus(),styles:this.computeStyles(),hoverDelegate:this._register(this.instantiationService.createInstance(Cs))},s=this._register(this.instantiationService.createInstance(pn,{...i,...t}));return s.layout(e.activeContainerDimension,e.activeContainerOffset.quickPickTop),this._register(e.onDidLayoutActiveContainer((t=>{(0,U.zk)(e.activeContainer)===(0,U.zk)(s.container)&&s.layout(t,e.activeContainerOffset.quickPickTop)}))),this._register(e.onDidChangeActiveContainer((()=>{s.isVisible()||s.layout(e.activeContainerDimension,e.activeContainerOffset.quickPickTop)}))),this._register(s.onShow((()=>{this.resetContextKeys(),this._onShow.fire()}))),this._register(s.onHide((()=>{this.resetContextKeys(),this._onHide.fire()}))),s}setContextKey(e){let t;e&&(t=this.contexts.get(e),t||(t=new ie.N1(e,!1).bindTo(this.contextKeyService),this.contexts.set(e,t))),t&&t.get()||(this.resetContextKeys(),t?.set(!0))}resetContextKeys(){this.contexts.forEach((e=>{e.get()&&e.reset()}))}pick(e,t,i=at.XO.None){return this.controller.pick(e,t,i)}createQuickPick(e={useSeparators:!1}){return this.controller.createQuickPick(e)}createInputBox(){return this.controller.createInputBox()}updateStyles(){this.hasController&&this.controller.applyStyles(this.computeStyles())}computeStyles(){return{widget:{quickInputBackground:(0,Ne.GuP)(Ne.ELA),quickInputForeground:(0,Ne.GuP)(Ne.HJZ),quickInputTitleBackground:(0,Ne.GuP)(Ne.er1),widgetBorder:(0,Ne.GuP)(Ne.DSL),widgetShadow:(0,Ne.GuP)(Ne.f9l)},inputBox:wi.ho,toggle:wi.mk,countBadge:wi.m$,button:wi.cv,progressBar:wi.oJ,keybindingLabel:wi.ir,list:(0,wi.t8)({listBackground:Ne.ELA,listFocusBackground:Ne.AlL,listFocusForeground:Ne.nH,listInactiveFocusForeground:Ne.nH,listInactiveSelectionIconForeground:Ne.c7i,listInactiveFocusBackground:Ne.AlL,listFocusOutline:Ne.buw,listInactiveFocusOutline:Ne.buw}),pickerGroup:{pickerGroupBorder:(0,Ne.GuP)(Ne.iwL),pickerGroupForeground:(0,Ne.GuP)(Ne.NBf)}}}};_n=mn([fn(0,ae._Y),fn(1,ie.fN),fn(2,Z.Gy),fn(3,le),fn(4,Me.pG)],_n);var vn=i(6921),Cn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},bn=function(e,t){return function(i,s){t(i,s,e)}};let En=class extends _n{constructor(e,t,i,s,n,r){super(t,i,s,new ue(e.getContainerDomNode(),n),r),this.host=void 0;const o=yn.get(e);if(o){const t=o.widget;this.host={_serviceBrand:void 0,get mainContainer(){return t.getDomNode()},getContainer:()=>t.getDomNode(),whenContainerStylesLoaded(){},get containers(){return[t.getDomNode()]},get activeContainer(){return t.getDomNode()},get mainContainerDimension(){return e.getLayoutInfo()},get activeContainerDimension(){return e.getLayoutInfo()},get onDidLayoutMainContainer(){return e.onDidLayoutChange},get onDidLayoutActiveContainer(){return e.onDidLayoutChange},get onDidLayoutContainer(){return Q.Jh.map(e.onDidLayoutChange,(e=>({container:t.getDomNode(),dimension:e})))},get onDidChangeActiveContainer(){return Q.Jh.None},get onDidAddContainer(){return Q.Jh.None},get mainContainerOffset(){return{top:0,quickPickTop:0}},get activeContainerOffset(){return{top:0,quickPickTop:0}},focus:()=>e.focus()}}else this.host=void 0}createController(){return super.createController(this.host)}};En=Cn([bn(1,ae._Y),bn(2,ie.fN),bn(3,Z.Gy),bn(4,g.T),bn(5,Me.pG)],En);let Sn=class{get activeService(){const e=this.codeEditorService.getFocusedCodeEditor();if(!e)throw new Error("Quick input service needs a focused editor to work.");let t=this.mapEditorToService.get(e);if(!t){const i=t=this.instantiationService.createInstance(En,e);this.mapEditorToService.set(e,t),(0,vn.P)(e.onDidDispose)((()=>{i.dispose(),this.mapEditorToService.delete(e)}))}return t}get currentQuickInput(){return this.activeService.currentQuickInput}get quickAccess(){return this.activeService.quickAccess}constructor(e,t){this.instantiationService=e,this.codeEditorService=t,this.mapEditorToService=new Map}pick(e,t,i=at.XO.None){return this.activeService.pick(e,t,i)}createQuickPick(e={useSeparators:!1}){return this.activeService.createQuickPick(e)}createInputBox(){return this.activeService.createInputBox()}};Sn=Cn([bn(0,ae._Y),bn(1,g.T)],Sn);class yn{static{this.ID="editor.controller.quickInput"}static get(e){return e.getContribution(yn.ID)}constructor(e){this.editor=e,this.widget=new wn(this.editor)}dispose(){this.widget.dispose()}}class wn{static{this.ID="editor.contrib.quickInputWidget"}constructor(e){this.codeEditor=e,this.domNode=document.createElement("div"),this.codeEditor.addOverlayWidget(this)}getId(){return wn.ID}getDomNode(){return this.domNode}getPosition(){return{preference:2}}dispose(){this.codeEditor.removeOverlayWidget(this)}}(0,u.HW)(yn.ID,yn,4);var Ln=i(10424),Rn=i(24520),Tn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xn=function(e,t){return function(i,s){t(i,s,e)}};let kn=class extends l.jG{constructor(e,t,i){super(),this._contextKeyService=e,this._layoutService=t,this._configurationService=i,this._accessibilitySupport=0,this._onDidChangeScreenReaderOptimized=new Q.vl,this._onDidChangeReducedMotion=new Q.vl,this._onDidChangeLinkUnderline=new Q.vl,this._accessibilityModeEnabledContext=Ve.f.bindTo(this._contextKeyService);const s=()=>this._accessibilityModeEnabledContext.set(this.isScreenReaderOptimized());this._register(this._configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration("editor.accessibilitySupport")&&(s(),this._onDidChangeScreenReaderOptimized.fire()),e.affectsConfiguration("workbench.reduceMotion")&&(this._configMotionReduced=this._configurationService.getValue("workbench.reduceMotion"),this._onDidChangeReducedMotion.fire())}))),s(),this._register(this.onDidChangeScreenReaderOptimized((()=>s())));const n=a.G.matchMedia("(prefers-reduced-motion: reduce)");this._systemMotionReduced=n.matches,this._configMotionReduced=this._configurationService.getValue("workbench.reduceMotion"),this._linkUnderlinesEnabled=this._configurationService.getValue("accessibility.underlineLinks"),this.initReducedMotionListeners(n),this.initLinkUnderlineListeners()}initReducedMotionListeners(e){this._register((0,U.ko)(e,"change",(()=>{this._systemMotionReduced=e.matches,"auto"===this._configMotionReduced&&this._onDidChangeReducedMotion.fire()})));const t=()=>{const e=this.isMotionReduced();this._layoutService.mainContainer.classList.toggle("reduce-motion",e),this._layoutService.mainContainer.classList.toggle("enable-motion",!e)};t(),this._register(this.onDidChangeReducedMotion((()=>t())))}initLinkUnderlineListeners(){this._register(this._configurationService.onDidChangeConfiguration((e=>{if(e.affectsConfiguration("accessibility.underlineLinks")){const e=this._configurationService.getValue("accessibility.underlineLinks");this._linkUnderlinesEnabled=e,this._onDidChangeLinkUnderline.fire()}})));const e=()=>{const e=this._linkUnderlinesEnabled;this._layoutService.mainContainer.classList.toggle("underline-links",e)};e(),this._register(this.onDidChangeLinkUnderlines((()=>e())))}onDidChangeLinkUnderlines(e){return this._onDidChangeLinkUnderline.event(e)}get onDidChangeScreenReaderOptimized(){return this._onDidChangeScreenReaderOptimized.event}isScreenReaderOptimized(){const e=this._configurationService.getValue("editor.accessibilitySupport");return"on"===e||"auto"===e&&2===this._accessibilitySupport}get onDidChangeReducedMotion(){return this._onDidChangeReducedMotion.event}isMotionReduced(){const e=this._configMotionReduced;return"on"===e||"auto"===e&&this._systemMotionReduced}getAccessibilitySupport(){return this._accessibilitySupport}};kn=Tn([xn(0,ie.fN),xn(1,le),xn(2,Me.pG)],kn);var An,Nn=i(60858),In=i(85600),On=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Dn=function(e,t){return function(i,s){t(i,s,e)}};const Mn="application/vnd.code.resources";let Pn=class extends l.jG{static{An=this}constructor(e,t){super(),this.layoutService=e,this.logService=t,this.mapTextToType=new Map,this.findText="",this.resources=[],this.resourcesStateHash=void 0,(oi.nr||oi.c8)&&this.installWebKitWriteTextWorkaround(),this._register(Q.Jh.runAndSubscribe(U.Iv,(({window:e,disposables:t})=>{t.add((0,U.ko)(e.document,"copy",(()=>this.clearResourcesState())))}),{window:a.G,disposables:this._store}))}installWebKitWriteTextWorkaround(){const e=()=>{const e=new m.Zv;this.webKitPendingClipboardWritePromise&&!this.webKitPendingClipboardWritePromise.isSettled&&this.webKitPendingClipboardWritePromise.cancel(),this.webKitPendingClipboardWritePromise=e,(0,U.fz)().navigator.clipboard.write([new ClipboardItem({"text/plain":e.p})]).catch((async t=>{t instanceof Error&&"NotAllowedError"===t.name&&e.isRejected||this.logService.error(t)}))};this._register(Q.Jh.runAndSubscribe(this.layoutService.onDidAddContainer,(({container:t,disposables:i})=>{i.add((0,U.ko)(t,"click",e)),i.add((0,U.ko)(t,"keydown",e))}),{container:this.layoutService.mainContainer,disposables:this._store}))}async writeText(e,t){if(this.clearResourcesState(),t)this.mapTextToType.set(t,e);else{if(this.webKitPendingClipboardWritePromise)return this.webKitPendingClipboardWritePromise.complete(e);try{return await(0,U.fz)().navigator.clipboard.writeText(e)}catch(i){console.error(i)}this.fallbackWriteText(e)}}fallbackWriteText(e){const t=(0,U.a)(),i=t.activeElement,s=t.body.appendChild((0,U.$)("textarea",{"aria-hidden":!0}));s.style.height="1px",s.style.width="1px",s.style.position="absolute",s.value=e,s.focus(),s.select(),t.execCommand("copy"),(0,U.sb)(i)&&i.focus(),s.remove()}async readText(e){if(e)return this.mapTextToType.get(e)||"";try{return await(0,U.fz)().navigator.clipboard.readText()}catch(t){console.error(t)}return""}async readFindText(){return this.findText}async writeFindText(e){this.findText=e}static{this.MAX_RESOURCE_STATE_SOURCE_LENGTH=1e3}async readResources(){try{const e=await(0,U.fz)().navigator.clipboard.read();for(const t of e)if(t.types.includes(`web ${Mn}`)){const e=await t.getType(`web ${Mn}`);return JSON.parse(await e.text()).map((e=>h.r.from(e)))}}catch(t){}const e=await this.computeResourcesStateHash();return this.resourcesStateHash!==e&&this.clearResourcesState(),this.resources}async computeResourcesStateHash(){if(0===this.resources.length)return;const e=await this.readText();return(0,In.tW)(e.substring(0,An.MAX_RESOURCE_STATE_SOURCE_LENGTH))}clearInternalState(){this.clearResourcesState()}clearResourcesState(){this.resources=[],this.resourcesStateHash=void 0}};Pn=An=On([Dn(0,le),Dn(1,I.rr)],Pn);var Fn=i(54770),Un=i(42522),Hn=i(4853),Bn=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Wn=function(e,t){return function(i,s){t(i,s,e)}};const Vn="data-keybinding-context";class zn{constructor(e,t){this._id=e,this._parent=t,this._value=Object.create(null),this._value._contextId=e}get value(){return{...this._value}}setValue(e,t){return this._value[e]!==t&&(this._value[e]=t,!0)}removeValue(e){return e in this._value&&(delete this._value[e],!0)}getValue(e){const t=this._value[e];return"undefined"===typeof t&&this._parent?this._parent.getValue(e):t}}class Gn extends zn{static{this.INSTANCE=new Gn}constructor(){super(-1,null)}setValue(e,t){return!1}removeValue(e){return!1}getValue(e){}}class jn extends zn{static{this._keyPrefix="config."}constructor(e,t,i){super(e,null),this._configurationService=t,this._values=Hn.cB.forConfigKeys(),this._listener=this._configurationService.onDidChangeConfiguration((e=>{if(7===e.source){const e=Array.from(this._values,(([e])=>e));this._values.clear(),i.fire(new qn(e))}else{const t=[];for(const i of e.affectedKeys){const e=`config.${i}`,s=this._values.findSuperstr(e);void 0!==s&&(t.push(...Un.f.map(s,(([e])=>e))),this._values.deleteSuperstr(e)),this._values.has(e)&&(t.push(e),this._values.delete(e))}i.fire(new qn(t))}}))}dispose(){this._listener.dispose()}getValue(e){if(0!==e.indexOf(jn._keyPrefix))return super.getValue(e);if(this._values.has(e))return this._values.get(e);const t=e.substr(jn._keyPrefix.length),i=this._configurationService.getValue(t);let s;switch(typeof i){case"number":case"boolean":case"string":s=i;break;default:s=Array.isArray(i)?JSON.stringify(i):i}return this._values.set(e,s),s}setValue(e,t){return super.setValue(e,t)}removeValue(e){return super.removeValue(e)}}class Kn{constructor(e,t,i){this._service=e,this._key=t,this._defaultValue=i,this.reset()}set(e){this._service.setContext(this._key,e)}reset(){"undefined"===typeof this._defaultValue?this._service.removeContext(this._key):this._service.setContext(this._key,this._defaultValue)}get(){return this._service.getContextKeyValue(this._key)}}class Yn{constructor(e){this.key=e}affectsSome(e){return e.has(this.key)}allKeysContainedIn(e){return this.affectsSome(e)}}class qn{constructor(e){this.keys=e}affectsSome(e){for(const t of this.keys)if(e.has(t))return!0;return!1}allKeysContainedIn(e){return this.keys.every((t=>e.has(t)))}}class $n{constructor(e){this.events=e}affectsSome(e){for(const t of this.events)if(t.affectsSome(e))return!0;return!1}allKeysContainedIn(e){return this.events.every((t=>t.allKeysContainedIn(e)))}}class Qn extends l.jG{constructor(e){super(),this._onDidChangeContext=this._register(new Q.fV({merge:e=>new $n(e)})),this.onDidChangeContext=this._onDidChangeContext.event,this._isDisposed=!1,this._myContextId=e}createKey(e,t){if(this._isDisposed)throw new Error("AbstractContextKeyService has been disposed");return new Kn(this,e,t)}bufferChangeEvents(e){this._onDidChangeContext.pause();try{e()}finally{this._onDidChangeContext.resume()}}createScoped(e){if(this._isDisposed)throw new Error("AbstractContextKeyService has been disposed");return new Zn(this,e)}contextMatchesRules(e){if(this._isDisposed)throw new Error("AbstractContextKeyService has been disposed");const t=this.getContextValuesContainer(this._myContextId);return!e||e.evaluate(t)}getContextKeyValue(e){if(!this._isDisposed)return this.getContextValuesContainer(this._myContextId).getValue(e)}setContext(e,t){if(this._isDisposed)return;const i=this.getContextValuesContainer(this._myContextId);i&&i.setValue(e,t)&&this._onDidChangeContext.fire(new Yn(e))}removeContext(e){this._isDisposed||this.getContextValuesContainer(this._myContextId).removeValue(e)&&this._onDidChangeContext.fire(new Yn(e))}getContext(e){return this._isDisposed?Gn.INSTANCE:this.getContextValuesContainer(function(e){for(;e;){if(e.hasAttribute(Vn)){const t=e.getAttribute(Vn);return t?parseInt(t,10):NaN}e=e.parentElement}return 0}(e))}dispose(){super.dispose(),this._isDisposed=!0}}let Xn=class extends Qn{constructor(e){super(0),this._contexts=new Map,this._lastContextId=0;const t=this._register(new jn(this._myContextId,e,this._onDidChangeContext));this._contexts.set(this._myContextId,t)}getContextValuesContainer(e){return this._isDisposed?Gn.INSTANCE:this._contexts.get(e)||Gn.INSTANCE}createChildContext(e=this._myContextId){if(this._isDisposed)throw new Error("ContextKeyService has been disposed");const t=++this._lastContextId;return this._contexts.set(t,new zn(t,this.getContextValuesContainer(e))),t}disposeContext(e){this._isDisposed||this._contexts.delete(e)}};Xn=Bn([Wn(0,Me.pG)],Xn);class Zn extends Qn{constructor(e,t){if(super(e.createChildContext()),this._parentChangeListener=this._register(new l.HE),this._parent=e,this._updateParentChangeListener(),this._domNode=t,this._domNode.hasAttribute(Vn)){let e="";this._domNode.classList&&(e=Array.from(this._domNode.classList.values()).join(", ")),console.error("Element already has context attribute"+(e?": "+e:""))}this._domNode.setAttribute(Vn,String(this._myContextId))}_updateParentChangeListener(){this._parentChangeListener.value=this._parent.onDidChangeContext((e=>{const t=this._parent.getContextValuesContainer(this._myContextId).value;var i;i=t,e.allKeysContainedIn(new Set(Object.keys(i)))||this._onDidChangeContext.fire(e)}))}dispose(){this._isDisposed||(this._parent.disposeContext(this._myContextId),this._domNode.removeAttribute(Vn),super.dispose())}getContextValuesContainer(e){return this._isDisposed?Gn.INSTANCE:this._parent.getContextValuesContainer(e)}createChildContext(e=this._myContextId){if(this._isDisposed)throw new Error("ScopedContextKeyService has been disposed");return this._parent.createChildContext(e)}disposeContext(e){this._isDisposed||this._parent.disposeContext(e)}}St.w.registerCommand("_setContext",(function(e,t,i){e.get(ie.fN).createKey(String(t),function(e){return(0,p.PI)(e,(e=>"object"===typeof e&&1===e.$mid?h.r.revive(e).toString():e instanceof h.r?e.toString():void 0))}(i))})),St.w.registerCommand({id:"getContextKeyInfo",handler:()=>[...ie.N1.all()].sort(((e,t)=>e.key.localeCompare(t.key))),metadata:{description:(0,E.kg)("getContextKeyInfo","A command that returns information about context keys"),args:[]}}),St.w.registerCommand("_generateContextKeyInfo",(function(){const e=[],t=new Set;for(const i of ie.N1.all())t.has(i.key)||(t.add(i.key),e.push(i));e.sort(((e,t)=>e.key.localeCompare(t.key))),console.log(JSON.stringify(e,void 0,2))}));var Jn=i(84040);class er{constructor(e,t){this.key=e,this.data=t,this.incoming=new Map,this.outgoing=new Map}}class tr{constructor(e){this._hashFn=e,this._nodes=new Map}roots(){const e=[];for(const t of this._nodes.values())0===t.outgoing.size&&e.push(t);return e}insertEdge(e,t){const i=this.lookupOrInsertNode(e),s=this.lookupOrInsertNode(t);i.outgoing.set(s.key,s),s.incoming.set(i.key,i)}removeNode(e){const t=this._hashFn(e);this._nodes.delete(t);for(const i of this._nodes.values())i.outgoing.delete(t),i.incoming.delete(t)}lookupOrInsertNode(e){const t=this._hashFn(e);let i=this._nodes.get(t);return i||(i=new er(t,e),this._nodes.set(t,i)),i}isEmpty(){return 0===this._nodes.size}toString(){const e=[];for(const[t,i]of this._nodes)e.push(`${t}\n\t(-> incoming)[${[...i.incoming.keys()].join(", ")}]\n\t(outgoing ->)[${[...i.outgoing.keys()].join(",")}]\n`);return e.join("\n")}findCycleSlow(){for(const[e,t]of this._nodes){const i=new Set([e]),s=this._findCycle(t,i);if(s)return s}}_findCycle(e,t){for(const[i,s]of e.outgoing){if(t.has(i))return[...t,i].join(" -> ");t.add(i);const e=this._findCycle(s,t);if(e)return e;t.delete(i)}}}var ir=i(58345);class sr extends Error{constructor(e){super("cyclic dependency between services"),this.message=e.findCycleSlow()??`UNABLE to detect cycle, dumping graph: \n${e.toString()}`}}class nr{constructor(e=new ir.a,t=!1,i,s=false){this._services=e,this._strict=t,this._parent=i,this._enableTracing=s,this._isDisposed=!1,this._servicesToMaybeDispose=new Set,this._children=new Set,this._activeInstantiations=new Set,this._services.set(ae._Y,this),this._globalGraph=s?i?._globalGraph??new tr((e=>e)):void 0}dispose(){if(!this._isDisposed){this._isDisposed=!0,(0,l.AS)(this._children),this._children.clear();for(const e of this._servicesToMaybeDispose)(0,l.Xm)(e)&&e.dispose();this._servicesToMaybeDispose.clear()}}_throwIfDisposed(){if(this._isDisposed)throw new Error("InstantiationService has been disposed")}createChild(e,t){this._throwIfDisposed();const i=this,s=new class extends nr{dispose(){i._children.delete(s),super.dispose()}}(e,this._strict,this,this._enableTracing);return this._children.add(s),t?.add(s),s}invokeFunction(e,...t){this._throwIfDisposed();const i=rr.traceInvocation(this._enableTracing,e);let s=!1;try{return e({get:e=>{if(s)throw(0,v.iH)("service accessor is only valid during the invocation of its target method");const t=this._getOrCreateServiceInstance(e,i);if(!t)throw new Error(`[invokeFunction] unknown service '${e}'`);return t}},...t)}finally{s=!0,i.stop()}}createInstance(e,...t){let i,s;return this._throwIfDisposed(),e instanceof Jn.d?(i=rr.traceCreation(this._enableTracing,e.ctor),s=this._createInstance(e.ctor,e.staticArguments.concat(t),i)):(i=rr.traceCreation(this._enableTracing,e),s=this._createInstance(e,t,i)),i.stop(),s}_createInstance(e,t=[],i){const s=ae._$.getServiceDependencies(e).sort(((e,t)=>e.index-t.index)),n=[];for(const o of s){const t=this._getOrCreateServiceInstance(o.id,i);t||this._throwIfStrict(`[createInstance] ${e.name} depends on UNKNOWN service ${o.id}.`,!1),n.push(t)}const r=s.length>0?s[0].index:t.length;if(t.length!==r){console.trace(`[createInstance] First service dependency of ${e.name} at position ${r+1} conflicts with ${t.length} static arguments`);const i=r-t.length;t=i>0?t.concat(new Array(i)):t.slice(0,r)}return Reflect.construct(e,t.concat(n))}_setCreatedServiceInstance(e,t){if(this._services.get(e)instanceof Jn.d)this._services.set(e,t);else{if(!this._parent)throw new Error("illegalState - setting UNKNOWN service instance");this._parent._setCreatedServiceInstance(e,t)}}_getServiceInstanceOrDescriptor(e){const t=this._services.get(e);return!t&&this._parent?this._parent._getServiceInstanceOrDescriptor(e):t}_getOrCreateServiceInstance(e,t){this._globalGraph&&this._globalGraphImplicitDependency&&this._globalGraph.insertEdge(this._globalGraphImplicitDependency,String(e));const i=this._getServiceInstanceOrDescriptor(e);return i instanceof Jn.d?this._safeCreateAndCacheServiceInstance(e,i,t.branch(e,!0)):(t.branch(e,!1),i)}_safeCreateAndCacheServiceInstance(e,t,i){if(this._activeInstantiations.has(e))throw new Error(`illegal state - RECURSIVELY instantiating service '${e}'`);this._activeInstantiations.add(e);try{return this._createAndCacheServiceInstance(e,t,i)}finally{this._activeInstantiations.delete(e)}}_createAndCacheServiceInstance(e,t,i){const s=new tr((e=>e.id.toString()));let n=0;const r=[{id:e,desc:t,_trace:i}],o=new Set;for(;r.length;){const t=r.pop();if(!o.has(String(t.id))){if(o.add(String(t.id)),s.lookupOrInsertNode(t),n++>1e3)throw new sr(s);for(const i of ae._$.getServiceDependencies(t.desc.ctor)){const n=this._getServiceInstanceOrDescriptor(i.id);if(n||this._throwIfStrict(`[createInstance] ${e} depends on ${i.id} which is NOT registered.`,!0),this._globalGraph?.insertEdge(String(t.id),String(i.id)),n instanceof Jn.d){const e={id:i.id,desc:n,_trace:t._trace.branch(i.id,!0)};s.insertEdge(t,e),r.push(e)}}}}for(;;){const e=s.roots();if(0===e.length){if(!s.isEmpty())throw new sr(s);break}for(const{data:t}of e){if(this._getServiceInstanceOrDescriptor(t.id)instanceof Jn.d){const e=this._createServiceInstanceWithOwner(t.id,t.desc.ctor,t.desc.staticArguments,t.desc.supportsDelayedInstantiation,t._trace);this._setCreatedServiceInstance(t.id,e)}s.removeNode(t)}}return this._getServiceInstanceOrDescriptor(e)}_createServiceInstanceWithOwner(e,t,i=[],s,n){if(this._services.get(e)instanceof Jn.d)return this._createServiceInstance(e,t,i,s,n,this._servicesToMaybeDispose);if(this._parent)return this._parent._createServiceInstanceWithOwner(e,t,i,s,n);throw new Error(`illegalState - creating UNKNOWN service instance ${t.name}`)}_createServiceInstance(e,t,i=[],s,n,r){if(s){const s=new nr(void 0,this._strict,this,this._enableTracing);s._globalGraphImplicitDependency=String(e);const o=new Map,a=new m.F6((()=>{const e=s._createInstance(t,i,n);for(const[t,i]of o){const s=e[t];if("function"===typeof s)for(const t of i)t.disposable=s.apply(e,t.listener)}return o.clear(),r.add(e),e}));return new Proxy(Object.create(null),{get(e,t){if(!a.isInitialized&&"string"===typeof t&&(t.startsWith("onDid")||t.startsWith("onWill"))){let e=o.get(t);e||(e=new X.w,o.set(t,e));return(i,s,n)=>{if(a.isInitialized)return a.value[t](i,s,n);{const t={listener:[i,s,n],disposable:void 0},r=e.push(t);return(0,l.s)((()=>{r(),t.disposable?.dispose()}))}}}if(t in e)return e[t];const i=a.value;let s=i[t];return"function"!==typeof s||(s=s.bind(i),e[t]=s),s},set:(e,t,i)=>(a.value[t]=i,!0),getPrototypeOf:e=>t.prototype})}{const e=this._createInstance(t,i,n);return r.add(e),e}}_throwIfStrict(e,t){if(t&&console.warn(e),this._strict)throw new Error(e)}}class rr{static{this.all=new Set}static{this._None=new class extends rr{constructor(){super(0,null)}stop(){}branch(){return this}}}static traceInvocation(e,t){return e?new rr(2,t.name||(new Error).stack.split("\n").slice(3,4).join("\n")):rr._None}static traceCreation(e,t){return e?new rr(1,t.name):rr._None}static{this._totals=0}constructor(e,t){this.type=e,this.name=t,this._start=Date.now(),this._dep=[]}branch(e,t){const i=new rr(3,e.toString());return this._dep.push([e,t,i]),i}stop(){const e=Date.now()-this._start;rr._totals+=e;let t=!1;const i=[`${1===this.type?"CREATE":"CALL"} ${this.name}`,`${function e(i,s){const n=[],r=new Array(i+1).join("\t");for(const[o,a,l]of s._dep)if(a&&l){t=!0,n.push(`${r}CREATES -> ${o}`);const s=e(i+1,l);s&&n.push(s)}else n.push(`${r}uses -> ${o}`);return n.join("\n")}(1,this)}`,`DONE, took ${e.toFixed(2)}ms (grand total ${rr._totals.toFixed(2)}ms)`];(e>2||t)&&rr.all.add(i.join("\n"))}}var or=i(75147);const ar=new Set([C.ny.inMemory,C.ny.vscodeSourceControl,C.ny.walkThrough,C.ny.walkThroughSnippet,C.ny.vscodeChatCodeBlock]);class lr{constructor(){this._byResource=new yt.fT,this._byOwner=new Map}set(e,t,i){let s=this._byResource.get(e);s||(s=new Map,this._byResource.set(e,s)),s.set(t,i);let n=this._byOwner.get(t);n||(n=new yt.fT,this._byOwner.set(t,n)),n.set(e,i)}get(e,t){const i=this._byResource.get(e);return i?.get(t)}delete(e,t){let i=!1,s=!1;const n=this._byResource.get(e);n&&(i=n.delete(t));const r=this._byOwner.get(t);if(r&&(s=r.delete(e)),i!==s)throw new Error("illegal state");return i&&s}values(e){return"string"===typeof e?this._byOwner.get(e)?.values()??Un.f.empty():h.r.isUri(e)?this._byResource.get(e)?.values()??Un.f.empty():Un.f.map(Un.f.concat(...this._byOwner.values()),(e=>e[1]))}}class cr{constructor(e){this.errors=0,this.infos=0,this.warnings=0,this.unknowns=0,this._data=new yt.fT,this._service=e,this._subscription=e.onMarkerChanged(this._update,this)}dispose(){this._subscription.dispose()}_update(e){for(const t of e){const e=this._data.get(t);e&&this._substract(e);const i=this._resourceStats(t);this._add(i),this._data.set(t,i)}}_resourceStats(e){const t={errors:0,warnings:0,infos:0,unknowns:0};if(ar.has(e.scheme))return t;for(const{severity:i}of this._service.read({resource:e}))i===or.cj.Error?t.errors+=1:i===or.cj.Warning?t.warnings+=1:i===or.cj.Info?t.infos+=1:t.unknowns+=1;return t}_substract(e){this.errors-=e.errors,this.warnings-=e.warnings,this.infos-=e.infos,this.unknowns-=e.unknowns}_add(e){this.errors+=e.errors,this.warnings+=e.warnings,this.infos+=e.infos,this.unknowns+=e.unknowns}}class hr{constructor(){this._onMarkerChanged=new Q.uI({delay:0,merge:hr._merge}),this.onMarkerChanged=this._onMarkerChanged.event,this._data=new lr,this._stats=new cr(this)}dispose(){this._stats.dispose(),this._onMarkerChanged.dispose()}remove(e,t){for(const i of t||[])this.changeOne(e,i,[])}changeOne(e,t,i){if((0,b.Ct)(i)){this._data.delete(t,e)&&this._onMarkerChanged.fire([t])}else{const s=[];for(const n of i){const i=hr._toMarker(e,t,n);i&&s.push(i)}this._data.set(t,e,s),this._onMarkerChanged.fire([t])}}static _toMarker(e,t,i){let{code:s,severity:n,message:r,source:o,startLineNumber:a,startColumn:l,endLineNumber:c,endColumn:h,relatedInformation:d,tags:u}=i;if(r)return a=a>0?a:1,l=l>0?l:1,c=c>=a?c:a,h=h>0?h:l,{resource:t,owner:e,code:s,severity:n,message:r,source:o,startLineNumber:a,startColumn:l,endLineNumber:c,endColumn:h,relatedInformation:d,tags:u}}changeAll(e,t){const i=[],s=this._data.values(e);if(s)for(const n of s){const t=Un.f.first(n);t&&(i.push(t.resource),this._data.delete(t.resource,e))}if((0,b.EI)(t)){const s=new yt.fT;for(const{resource:n,marker:r}of t){const t=hr._toMarker(e,n,r);if(!t)continue;const o=s.get(n);o?o.push(t):(s.set(n,[t]),i.push(n))}for(const[t,i]of s)this._data.set(t,e,i)}i.length>0&&this._onMarkerChanged.fire(i)}read(e=Object.create(null)){let{owner:t,resource:i,severities:s,take:n}=e;if((!n||n<0)&&(n=-1),t&&i){const e=this._data.get(i,t);if(e){const t=[];for(const i of e)if(hr._accept(i,s)){const e=t.push(i);if(n>0&&e===n)break}return t}return[]}if(t||i){const e=this._data.values(i??t),r=[];for(const t of e)for(const e of t)if(hr._accept(e,s)){const t=r.push(e);if(n>0&&t===n)return r}return r}{const e=[];for(const t of this._data.values())for(const i of t)if(hr._accept(i,s)){const t=e.push(i);if(n>0&&t===n)return e}return e}}static _accept(e,t){return void 0===t||(t&e.severity)===e.severity}static _merge(e){const t=new yt.fT;for(const i of e)for(const e of i)t.set(e,!0);return Array.from(t.keys())}}var dr=i(9711);class ur extends l.jG{get configurationModel(){return this._configurationModel}constructor(e){super(),this.logService=e,this._configurationModel=Tt.createEmptyModel(this.logService)}reload(){return this.resetConfigurationModel(),this.configurationModel}getConfigurationDefaultOverrides(){return{}}resetConfigurationModel(){this._configurationModel=Tt.createEmptyModel(this.logService);const e=Lt.O.as(wt.Fd.Configuration).getConfigurationProperties();this.updateConfigurationModel(Object.keys(e),e)}updateConfigurationModel(e,t){const i=this.getConfigurationDefaultOverrides();for(const s of e){const e=i[s],n=t[s];void 0!==e?this._configurationModel.setValue(s,e):n?this._configurationModel.setValue(s,n.default):this._configurationModel.removeValue(s)}}}var gr=i(87213);class pr extends l.jG{constructor(e,t=[]){super(),this.logger=new I.Dk([e,...t]),this._register(e.onDidChangeLogLevel((e=>this.setLevel(e))))}get onDidChangeLogLevel(){return this.logger.onDidChangeLogLevel}setLevel(e){this.logger.setLevel(e)}getLevel(){return this.logger.getLevel()}trace(e,...t){this.logger.trace(e,...t)}debug(e,...t){this.logger.debug(e,...t)}info(e,...t){this.logger.info(e,...t)}warn(e,...t){this.logger.warn(e,...t)}error(e,...t){this.logger.error(e,...t)}}var mr=i(72466),fr=i(97035),_r=i(44432);var vr=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Cr=function(e,t){return function(i,s){t(i,s,e)}};class br{constructor(e){this.disposed=!1,this.model=e,this._onWillDispose=new Q.vl}get textEditorModel(){return this.model}dispose(){this.disposed=!0,this._onWillDispose.fire()}}let Er=class{constructor(e){this.modelService=e}createModelReference(e){const t=this.modelService.getModel(e);return t?Promise.resolve(new l.BO(new br(t))):Promise.reject(new Error("Model not found"))}};Er=vr([Cr(0,A.IModelService)],Er);class Sr{static{this.NULL_PROGRESS_RUNNER={done:()=>{},total:()=>{},worked:()=>{}}}show(){return Sr.NULL_PROGRESS_RUNNER}async showWhile(e,t){await e}}class yr{static{this.NO_OP=new me.Kz}info(e){return this.notify({severity:ge.A.Info,message:e})}warn(e){return this.notify({severity:ge.A.Warning,message:e})}error(e){return this.notify({severity:ge.A.Error,message:e})}notify(e){switch(e.severity){case ge.A.Error:console.error(e.message);break;case ge.A.Warning:console.warn(e.message);break;default:console.log(e.message)}return yr.NO_OP}prompt(e,t,i,s){return yr.NO_OP}status(e,t){return l.jG.None}}let wr=class{constructor(e){this._onWillExecuteCommand=new Q.vl,this._onDidExecuteCommand=new Q.vl,this.onDidExecuteCommand=this._onDidExecuteCommand.event,this._instantiationService=e}executeCommand(e,...t){const i=St.w.getCommand(e);if(!i)return Promise.reject(new Error(`command '${e}' not found`));try{this._onWillExecuteCommand.fire({commandId:e,args:t});const s=this._instantiationService.invokeFunction.apply(this._instantiationService,[i.handler,...t]);return this._onDidExecuteCommand.fire({commandId:e,args:t}),Promise.resolve(s)}catch(s){return Promise.reject(s)}}};wr=vr([Cr(0,ae._Y)],wr);let Lr=class extends Ht{constructor(e,t,i,s,n,r){super(e,t,i,s,n),this._cachedResolver=null,this._dynamicKeybindings=[],this._domNodeListeners=[];const o=e=>{const t=new l.Cm;t.add(U.ko(e,U.Bx.KEY_DOWN,(e=>{const t=new Xe.Z(e);this._dispatch(t,t.target)&&(t.preventDefault(),t.stopPropagation())}))),t.add(U.ko(e,U.Bx.KEY_UP,(e=>{const t=new Xe.Z(e);this._singleModifierDispatch(t,t.target)&&t.preventDefault()}))),this._domNodeListeners.push(new Rr(e,t))},a=e=>{for(let t=0;t{e.getOption(61)||o(e.getContainerDomNode())};this._register(r.onCodeEditorAdd(c)),this._register(r.onCodeEditorRemove((e=>{e.getOption(61)||a(e.getContainerDomNode())}))),r.listCodeEditors().forEach(c);const h=e=>{o(e.getContainerDomNode())};this._register(r.onDiffEditorAdd(h)),this._register(r.onDiffEditorRemove((e=>{a(e.getContainerDomNode())}))),r.listDiffEditors().forEach(h)}addDynamicKeybinding(e,t,i,s){return(0,l.qE)(St.w.registerCommand(e,i),this.addDynamicKeybindings([{keybinding:t,command:e,when:s}]))}addDynamicKeybindings(e){const t=e.map((e=>({keybinding:(0,ft.Zv)(e.keybinding,We.OS),command:e.command??null,commandArgs:e.commandArgs,when:e.when,weight1:1e3,weight2:0,extensionId:null,isBuiltinExtension:!1})));return this._dynamicKeybindings=this._dynamicKeybindings.concat(t),this.updateResolver(),(0,l.s)((()=>{for(let e=0;ethis._log(e)))}return this._cachedResolver}_documentHasFocus(){return a.G.document.hasFocus()}_toNormalizedKeybindingItems(e,t){const i=[];let s=0;for(const n of e){const e=n.when||void 0,r=n.keybinding;if(r){const o=Yt.resolveKeybinding(r,We.OS);for(const r of o)i[s++]=new Vt(r,n.command,n.commandArgs,e,t,null,!1)}else i[s++]=new Vt(void 0,n.command,n.commandArgs,e,t,null,!1)}return i}resolveKeyboardEvent(e){const t=new ft.dG(e.ctrlKey,e.shiftKey,e.altKey,e.metaKey,e.keyCode);return new Yt([t],We.OS)}};Lr=vr([Cr(0,ie.fN),Cr(1,St.d),Cr(2,Qt.k),Cr(3,me.Ot),Cr(4,I.rr),Cr(5,g.T)],Lr);class Rr extends l.jG{constructor(e,t){super(),this.domNode=e,this._register(t)}}function Tr(e){return e&&"object"===typeof e&&(!e.overrideIdentifier||"string"===typeof e.overrideIdentifier)&&(!e.resource||e.resource instanceof h.r)}let xr=class{constructor(e){this.logService=e,this._onDidChangeConfiguration=new Q.vl,this.onDidChangeConfiguration=this._onDidChangeConfiguration.event;const t=new ur(e);this._configuration=new At(t.reload(),Tt.createEmptyModel(e),Tt.createEmptyModel(e),Tt.createEmptyModel(e),Tt.createEmptyModel(e),Tt.createEmptyModel(e),new yt.fT,Tt.createEmptyModel(e),new yt.fT,e),t.dispose()}getValue(e,t){const i="string"===typeof e?e:void 0,s=Tr(e)?e:Tr(t)?t:{};return this._configuration.getValue(i,s,void 0)}updateValues(e){const t={data:this._configuration.toData()},i=[];for(const s of e){const[e,t]=s;this.getValue(e)!==t&&(this._configuration.updateValue(e,t),i.push(e))}if(i.length>0){const e=new Nt({keys:i,overrides:[]},t,this._configuration,void 0,this.logService);e.source=8,this._onDidChangeConfiguration.fire(e)}return Promise.resolve()}updateValue(e,t,i,s){return this.updateValues([[e,t]])}inspect(e,t={}){return this._configuration.inspect(e,t,void 0)}};xr=vr([Cr(0,I.rr)],xr);let kr=class{constructor(e,t,i){this.configurationService=e,this.modelService=t,this.languageService=i,this._onDidChangeConfiguration=new Q.vl,this.configurationService.onDidChangeConfiguration((e=>{this._onDidChangeConfiguration.fire({affectedKeys:e.affectedKeys,affectsConfiguration:(t,i)=>e.affectsConfiguration(i)})}))}getValue(e,t,i){const s=bt.y.isIPosition(t)?t:null,n=s?"string"===typeof i?i:void 0:"string"===typeof t?t:void 0,r=e?this.getLanguage(e,s):void 0;return"undefined"===typeof n?this.configurationService.getValue({resource:e,overrideIdentifier:r}):this.configurationService.getValue(n,{resource:e,overrideIdentifier:r})}getLanguage(e,t){const i=this.modelService.getModel(e);return i?t?i.getLanguageIdAtPosition(t.lineNumber,t.column):i.getLanguageId():this.languageService.guessLanguageIdByFilepathOrFirstLine(e)}};kr=vr([Cr(0,Me.pG),Cr(1,A.IModelService),Cr(2,Ui.L)],kr);let Ar=class{constructor(e){this.configurationService=e}getEOL(e,t){const i=this.configurationService.getValue("files.eol",{overrideIdentifier:t,resource:e});return i&&"string"===typeof i&&"auto"!==i?i:We.j9||We.zx?"\n":"\r\n"}};Ar=vr([Cr(0,Me.pG)],Ar);class Nr{static{this.SCHEME="inmemory"}constructor(){const e=h.r.from({scheme:Nr.SCHEME,authority:"model",path:"/"});this.workspace={id:Xt.cn,folders:[new Xt.mX({uri:e,name:"",index:0})]}}getWorkspace(){return this.workspace}getWorkspaceFolder(e){return e&&e.scheme===Nr.SCHEME?this.workspace.folders[0]:null}}function Ir(e,t,i){if(!t)return;if(!(e instanceof xr))return;const s=[];Object.keys(t).forEach((e=>{(0,vt.vf)(e)&&s.push([`editor.${e}`,t[e]]),i&&(0,vt.Gn)(e)&&s.push([`diffEditor.${e}`,t[e]])})),s.length>0&&e.updateValues(s)}let Or=class{constructor(e){this._modelService=e}hasPreviewHandler(){return!1}async apply(e,t){const i=Array.isArray(e)?e:_t.jN.convert(e),s=new Map;for(const o of i){if(!(o instanceof _t.cw))throw new Error("bad edit - only text edits are supported");const e=this._modelService.getModel(o.resource);if(!e)throw new Error("bad edit - model not found");if("number"===typeof o.versionId&&e.getVersionId()!==o.versionId)throw new Error("bad state - model changed in the meantime");let t=s.get(e);t||(t=[],s.set(e,t)),t.push(Ct.k.replaceMove(T.Q.lift(o.textEdit.range),o.textEdit.text))}let n=0,r=0;for(const[o,a]of s)o.pushStackElement(),o.pushEditOperations([],a,(()=>[])),o.pushStackElement(),r+=1,n+=a.length;return{ariaSummary:c.GP(Zt.tu.bulkEditServiceSummary,n,r),isApplied:n>0}}};Or=vr([Cr(0,A.IModelService)],Or);let Dr=class extends ot{constructor(e,t){super(e),this._codeEditorService=t}showContextView(e,t,i){if(!t){const e=this._codeEditorService.getFocusedCodeEditor()||this._codeEditorService.getActiveCodeEditor();e&&(t=e.getContainerDomNode())}return super.showContextView(e,t,i)}};Dr=vr([Cr(0,le),Cr(1,g.T)],Dr);class Mr extends ti.LanguageService{constructor(){super()}}let Pr=class extends xi{constructor(e,t,i,s,n,r){super(e,t,i,s,n,r),this.configure({blockMouse:!1})}};Pr=vr([Cr(0,Qt.k),Cr(1,me.Ot),Cr(2,Oe.l),Cr(3,De.b),Cr(4,ni.ez),Cr(5,ie.fN)],Pr);const Fr={amdModuleId:"vs/editor/common/services/editorSimpleWorker",esmModuleLocation:void 0,label:"editorWorkerService"};let Ur=class extends j{constructor(e,t,i,s,n){super(Fr,e,t,i,s,n)}};Ur=vr([Cr(0,A.IModelService),Cr(1,N.ITextResourceConfigurationService),Cr(2,I.rr),Cr(3,x.JZ),Cr(4,D.ILanguageFeaturesService)],Ur);var Hr;(0,se.v)(I.rr,class extends pr{constructor(){super(new I.Cr)}},0),(0,se.v)(Me.pG,xr,0),(0,se.v)(N.ITextResourceConfigurationService,kr,0),(0,se.v)(N.ITextResourcePropertiesService,Ar,0),(0,se.v)(Xt.VR,Nr,0),(0,se.v)(qt.L,class{getUriLabel(e,t){return"file"===e.scheme?e.fsPath:e.path}getUriBasenameLabel(e){return(0,Jt.P8)(e)}},0),(0,se.v)(Qt.k,class{publicLog2(){}},0),(0,se.v)(pe.X,class{async confirm(e){return{confirmed:this.doConfirm(e.message,e.detail),checkboxChecked:!1}}doConfirm(e,t){let i=e;return t&&(i=i+"\n\n"+t),a.G.confirm(i)}async prompt(e){let t;if(this.doConfirm(e.message,e.detail)){const i=[...e.buttons??[]];e.cancelButton&&"string"!==typeof e.cancelButton&&"boolean"!==typeof e.cancelButton&&i.push(e.cancelButton),t=await(i[0]?.run({checkboxChecked:!1}))}return{result:t}}async error(e,t){await this.prompt({type:ge.A.Error,message:e,detail:t})}},0),(0,se.v)(fr.k,class{constructor(){this.isExtensionDevelopment=!1,this.isBuilt=!1}},0),(0,se.v)(me.Ot,yr,0),(0,se.v)(or.DR,hr,0),(0,se.v)(Ui.L,Mr,0),(0,se.v)(Rn.L,Ln.Sx,0),(0,se.v)(A.IModelService,Wi.ModelService,0),(0,se.v)(Bi.IMarkerDecorationsService,Hi.MarkerDecorationsService,0),(0,se.v)(ie.fN,Xn,0),(0,se.v)($t.G5,class{withProgress(e,t,i){return t({report:()=>{}})}},0),(0,se.v)($t.N8,Sr,0),(0,se.v)(dr.CS,dr.pc,0),(0,se.v)(Fi.IEditorWorkerService,Ur,0),(0,se.v)(_t.nu,Or,0),(0,se.v)(ei.L,class{constructor(){this._neverEmitter=new Q.vl,this.onDidChangeTrust=this._neverEmitter.event}isWorkspaceTrusted(){return!0}},0),(0,se.v)(Et.ITextModelService,Er,0),(0,se.v)(Ve.j,kn,0),(0,se.v)(Ns.PE,Ns.aG,0),(0,se.v)(St.d,wr,0),(0,se.v)(De.b,Lr,0),(0,se.v)(zi.GK,Sn,0),(0,se.v)(Oe.l,Dr,0),(0,se.v)(Ue.C,Pi,0),(0,se.v)(Fn.h,Pn,0),(0,se.v)(Oe.Z,Pr,0),(0,se.v)(ni.ez,Nn.$,0),(0,se.v)(gr.Nt,class{async playSignal(e,t){}},0),(0,se.v)(_r.ITreeSitterParserService,class{getParseResult(e){}},0),function(e){const t=new ir.a;for(const[o,a]of(0,se.N)())t.set(o,a);const i=new nr(t,!0);t.set(ae._Y,i),e.get=function(e){s||r({});const n=t.get(e);if(!n)throw new Error("Missing service "+e);return n instanceof Jn.d?i.invokeFunction((t=>t.get(e))):n};let s=!1;const n=new Q.vl;function r(e){if(s)return i;s=!0;for(const[i,s]of(0,se.N)())t.get(i)||t.set(i,s);for(const i in e)if(e.hasOwnProperty(i)){const s=(0,ae.u1)(i);t.get(s)instanceof Jn.d&&t.set(s,e[i])}const r=(0,mr.T)();for(const t of r)try{i.createInstance(t)}catch(o){(0,v.dz)(o)}return n.fire(),i}e.initialize=r,e.withServices=function(e){if(s)return e();const t=new l.Cm,i=t.add(n.event((()=>{i.dispose(),t.add(e())})));return t}}(Hr||(Hr={}));class Br extends ${constructor(e,t){super({amdModuleId:Fr.amdModuleId,esmModuleLocation:Fr.esmModuleLocation,label:t.label},t.keepIdleModels||!1,e),this._foreignModuleId=t.moduleId,this._foreignModuleCreateData=t.createData||null,this._foreignModuleHost=t.host||null,this._foreignProxy=null}fhr(e,t){if(!this._foreignModuleHost||"function"!==typeof this._foreignModuleHost[e])return Promise.reject(new Error("Missing method "+e+" or missing main thread foreign host."));try{return Promise.resolve(this._foreignModuleHost[e].apply(this._foreignModuleHost,t))}catch(i){return Promise.reject(i)}}_getForeignProxy(){return this._foreignProxy||(this._foreignProxy=this._getProxy().then((e=>{const t=this._foreignModuleHost?(0,p.V0)(this._foreignModuleHost):[];return e.$loadForeignModule(this._foreignModuleId,this._foreignModuleCreateData,t).then((t=>{this._foreignModuleCreateData=null;const i=(t,i)=>e.$fmr(t,i),s=(e,t)=>function(){const i=Array.prototype.slice.call(arguments,0);return t(e,i)},n={};for(const e of t)n[e]=s(e,i);return n}))}))),this._foreignProxy}getProxy(){return this._getForeignProxy()}withSyncedResources(e){return this.workerWithSyncedResources(e).then((e=>this.getProxy()))}}var Wr=i(79027),Vr=i(74196),zr=i(23452),Gr=i(62083),jr=i(83941),Kr=i(20788),Yr=i(16223),qr=i(35015),$r=i(87469),Qr=i(35600),Xr=i(92896);function Zr(e){return!function(e){return Array.isArray(e)}(e)}function Jr(e){return"string"===typeof e}function eo(e){return!Jr(e)}function to(e){return!e}function io(e,t){return e.ignoreCase&&t?t.toLowerCase():t}function so(e){return e.replace(/[&<>'"_]/g,"-")}function no(e,t){return new Error(`${e.languageId}: ${t}`)}function ro(e,t,i,s,n){let r=null;return t.replace(/\$((\$)|(#)|(\d\d?)|[sS](\d\d?)|@(\w+))/g,(function(t,o,a,l,c,h,d,u,g){return to(a)?to(l)?!to(c)&&c0;){const t=e.tokenizer[i];if(t)return t;const s=i.lastIndexOf(".");i=s<0?null:i.substr(0,s)}return null}var ao,lo=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},co=function(e,t){return function(i,s){t(i,s,e)}};class ho{static{this._INSTANCE=new ho(5)}static create(e,t){return this._INSTANCE.create(e,t)}constructor(e){this._maxCacheDepth=e,this._entries=Object.create(null)}create(e,t){if(null!==e&&e.depth>=this._maxCacheDepth)return new uo(e,t);let i=uo.getStackElementId(e);i.length>0&&(i+="|"),i+=t;let s=this._entries[i];return s||(s=new uo(e,t),this._entries[i]=s,s)}}class uo{constructor(e,t){this.parent=e,this.state=t,this.depth=(this.parent?this.parent.depth:0)+1}static getStackElementId(e){let t="";for(;null!==e;)t.length>0&&(t+="|"),t+=e.state,e=e.parent;return t}static _equals(e,t){for(;null!==e&&null!==t;){if(e===t)return!0;if(e.state!==t.state)return!1;e=e.parent,t=t.parent}return null===e&&null===t}equals(e){return uo._equals(this,e)}push(e){return ho.create(this,e)}pop(){return this.parent}popall(){let e=this;for(;e.parent;)e=e.parent;return e}switchTo(e){return ho.create(this.parent,e)}}class go{constructor(e,t){this.languageId=e,this.state=t}equals(e){return this.languageId===e.languageId&&this.state.equals(e.state)}clone(){return this.state.clone()===this.state?this:new go(this.languageId,this.state)}}class po{static{this._INSTANCE=new po(5)}static create(e,t){return this._INSTANCE.create(e,t)}constructor(e){this._maxCacheDepth=e,this._entries=Object.create(null)}create(e,t){if(null!==t)return new mo(e,t);if(null!==e&&e.depth>=this._maxCacheDepth)return new mo(e,t);const i=uo.getStackElementId(e);let s=this._entries[i];return s||(s=new mo(e,null),this._entries[i]=s,s)}}class mo{constructor(e,t){this.stack=e,this.embeddedLanguageData=t}clone(){return(this.embeddedLanguageData?this.embeddedLanguageData.clone():null)===this.embeddedLanguageData?this:po.create(this.stack,this.embeddedLanguageData)}equals(e){return e instanceof mo&&(!!this.stack.equals(e.stack)&&(null===this.embeddedLanguageData&&null===e.embeddedLanguageData||null!==this.embeddedLanguageData&&null!==e.embeddedLanguageData&&this.embeddedLanguageData.equals(e.embeddedLanguageData)))}}class fo{constructor(){this._tokens=[],this._languageId=null,this._lastTokenType=null,this._lastTokenLanguage=null}enterLanguage(e){this._languageId=e}emit(e,t){this._lastTokenType===t&&this._lastTokenLanguage===this._languageId||(this._lastTokenType=t,this._lastTokenLanguage=this._languageId,this._tokens.push(new Gr.ou(e,t,this._languageId)))}nestedLanguageTokenize(e,t,i,s){const n=i.languageId,r=i.state,o=Gr.dG.get(n);if(!o)return this.enterLanguage(n),this.emit(s,""),r;const a=o.tokenize(e,t,r);if(0!==s)for(const l of a.tokens)this._tokens.push(new Gr.ou(l.offset+s,l.type,l.language));else this._tokens=this._tokens.concat(a.tokens);return this._lastTokenType=null,this._lastTokenLanguage=null,this._languageId=null,a.endState}finalize(e){return new Gr.$M(this._tokens,e)}}class _o{constructor(e,t){this._languageService=e,this._theme=t,this._prependTokens=null,this._tokens=[],this._currentLanguageId=0,this._lastTokenMetadata=0}enterLanguage(e){this._currentLanguageId=this._languageService.languageIdCodec.encodeLanguageId(e)}emit(e,t){const i=1024|this._theme.match(this._currentLanguageId,t);this._lastTokenMetadata!==i&&(this._lastTokenMetadata=i,this._tokens.push(e),this._tokens.push(i))}static _merge(e,t,i){const s=null!==e?e.length:0,n=t.length,r=null!==i?i.length:0;if(0===s&&0===n&&0===r)return new Uint32Array(0);if(0===s&&0===n)return i;if(0===n&&0===r)return e;const o=new Uint32Array(s+n+r);null!==e&&o.set(e);for(let a=0;a{if(r)return;let t=!1;for(let i=0,s=e.changedLanguages.length;i{e.affectsConfiguration("editor.maxTokenizationLineLength")&&(this._maxTokenizationLineLength=this._configurationService.getValue("editor.maxTokenizationLineLength",{overrideIdentifier:this._languageId}))})))}getLoadStatus(){const e=[];for(const t in this._embeddedLanguages){const i=Gr.dG.get(t);if(i){if(i instanceof ao){const t=i.getLoadStatus();!1===t.loaded&&e.push(t.promise)}}else Gr.dG.isResolved(t)||e.push(Gr.dG.getOrCreate(t))}return 0===e.length?{loaded:!0}:{loaded:!1,promise:Promise.all(e).then((e=>{}))}}getInitialState(){const e=ho.create(null,this._lexer.start);return po.create(e,null)}tokenize(e,t,i){if(e.length>=this._maxTokenizationLineLength)return(0,Kr.$H)(this._languageId,i);const s=new fo,n=this._tokenize(e,t,i,s);return s.finalize(n)}tokenizeEncoded(e,t,i){if(e.length>=this._maxTokenizationLineLength)return(0,Kr.Lh)(this._languageService.languageIdCodec.encodeLanguageId(this._languageId),i);const s=new _o(this._languageService,this._standaloneThemeService.getColorTheme().tokenTheme),n=this._tokenize(e,t,i,s);return s.finalize(n)}_tokenize(e,t,i,s){return i.embeddedLanguageData?this._nestedTokenize(e,t,i,0,s):this._myTokenize(e,t,i,0,s)}_findLeavingNestedLanguageOffset(e,t){let i=this._lexer.tokenizer[t.stack.state];if(!i&&(i=oo(this._lexer,t.stack.state),!i))throw no(this._lexer,"tokenizer state is not defined: "+t.stack.state);let s=-1,n=!1;for(const r of i){if(!eo(r.action)||"@pop"!==r.action.nextEmbedded)continue;n=!0;let i=r.resolveRegex(t.stack.state);const o=i.source;if("^(?:"===o.substr(0,4)&&")"===o.substr(o.length-1,1)){const e=(i.ignoreCase?"i":"")+(i.unicode?"u":"");i=new RegExp(o.substr(4,o.length-5),e)}const a=e.search(i);-1===a||0!==a&&r.matchOnlyAtLineStart||(-1===s||a0&&n.nestedLanguageTokenize(o,!1,i.embeddedLanguageData,s);const a=e.substring(r);return this._myTokenize(a,t,i,s+r,n)}_safeRuleName(e){return e?e.name:"(unknown)"}_myTokenize(e,t,i,s,n){n.enterLanguage(this._languageId);const r=e.length,o=t&&this._lexer.includeLF?e+"\n":e,a=o.length;let l=i.embeddedLanguageData,c=i.stack,h=0,d=null,u=!0;for(;u||h=a)break;u=!1;let e=this._lexer.tokenizer[_];if(!e&&(e=oo(this._lexer,_),!e))throw no(this._lexer,"tokenizer state is not defined: "+_);const t=o.substr(h);for(const i of e)if((0===h||!i.matchOnlyAtLineStart)&&(v=t.match(i.resolveRegex(_)),v)){C=v[0],b=i.action;break}}if(v||(v=[""],C=""),b||(h=this._lexer.maxStack)throw no(this._lexer,"maximum tokenizer stack size reached: ["+c.state+","+c.parent.state+",...]");c=c.push(_)}else if("@pop"===b.next){if(c.depth<=1)throw no(this._lexer,"trying to pop an empty stack in rule: "+this._safeRuleName(E));c=c.pop()}else if("@popall"===b.next)c=c.popall();else{let e=ro(this._lexer,b.next,C,v,_);if("@"===e[0]&&(e=e.substr(1)),!oo(this._lexer,e))throw no(this._lexer,"trying to set a next state '"+e+"' that is undefined in rule: "+this._safeRuleName(E));c=c.push(e)}}b.log&&"string"===typeof b.log&&(g=this._lexer,p=this._lexer.languageId+": "+ro(this._lexer,b.log,C,v,_),console.log(`${g.languageId}: ${p}`))}if(null===y)throw no(this._lexer,"lexer rule has no well-defined action in rule: "+this._safeRuleName(E));const w=i=>{const r=this._languageService.getLanguageIdByLanguageName(i)||this._languageService.getLanguageIdByMimeType(i)||i,o=this._getNestedEmbeddedLanguageData(r);if(h0)throw no(this._lexer,"groups cannot be nested: "+this._safeRuleName(E));if(v.length!==y.length+1)throw no(this._lexer,"matched number of groups does not match the number of actions in rule: "+this._safeRuleName(E));let e=0;for(let t=1;te});class Eo{static colorizeElement(e,t,i,s){const n=(s=s||{}).theme||"vs",r=s.mimeType||i.getAttribute("lang")||i.getAttribute("data-lang");if(!r)return console.error("Mode not detected"),Promise.resolve();const o=t.getLanguageIdByMimeType(r)||r;e.setTheme(n);const a=i.firstChild?i.firstChild.nodeValue:"";i.className+=" "+n;return this.colorize(t,a||"",o,s).then((e=>{const t=bo?.createHTML(e)??e;i.innerHTML=t}),(e=>console.error(e)))}static async colorize(e,t,i,s){const n=e.languageIdCodec;let r=4;s&&"number"===typeof s.tabSize&&(r=s.tabSize),c.LU(t)&&(t=t.substr(1));const o=c.uz(t);if(!e.isRegisteredLanguageId(i))return So(o,r,n);const a=await Gr.dG.getOrCreate(i);return a?function(e,t,i,s){return new Promise(((n,r)=>{const o=()=>{const a=function(e,t,i,s){let n=[],r=i.getInitialState();for(let o=0,a=e.length;o"),r=l.endState}return n.join("")}(e,t,i,s);if(i instanceof vo){const e=i.getLoadStatus();if(!1===e.loaded)return void e.promise.then(o,r)}n(a)};o()}))}(o,r,a,n):So(o,r,n)}static colorizeLine(e,t,i,s,n=4){const r=Xr.qL.isBasicASCII(e,t),o=Xr.qL.containsRTL(e,r,i);return(0,Qr.Md)(new Qr.zL(!1,!0,e,!1,r,o,0,s,[],n,0,0,0,0,-1,"none",!1,!1,null)).html}static colorizeModelLine(e,t,i=4){const s=e.getLineContent(t);e.tokenization.forceTokenization(t);const n=e.tokenization.getLineTokens(t).inflate();return this.colorizeLine(s,e.mightContainNonBasicASCII(),e.mightContainRTL(),n,i)}}function So(e,t,i){let s=[];const n=new Uint32Array(2);n[0]=0,n[1]=33587200;for(let r=0,o=e.length;r")}return s.join("")}var yo=i(29611),wo=i(4360),Lo=i(42904),Ro=i(48196),To=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xo=function(e,t){return function(i,s){t(i,s,e)}};let ko=0,Ao=!1;let No=class extends n.x{constructor(e,t,i,s,n,r,o,l,c,h,d,u,g){const p={...t};p.ariaLabel=p.ariaLabel||Zt.vp.editorViewAccessibleLabel,super(e,p,{},i,s,n,r,c,h,d,u,g),this._standaloneKeybindingService=l instanceof Lr?l:null,function(e){if(!e){if(Ao)return;Ao=!0}ze.vr(e||a.G.document.body)}(p.ariaContainerElement),(0,Lo.MW)(((e,t)=>i.createInstance(Ie.fO,e,t,{}))),(0,Ro.e)(o)}addCommand(e,t,i){if(!this._standaloneKeybindingService)return console.warn("Cannot add command because the editor is configured with an unrecognized KeybindingService"),null;const s="DYNAMIC_"+ ++ko,n=ie.M$.deserialize(i);return this._standaloneKeybindingService.addDynamicKeybinding(s,e,t,n),s}createContextKey(e,t){return this._contextKeyService.createKey(e,t)}addAction(e){if("string"!==typeof e.id||"string"!==typeof e.label||"function"!==typeof e.run)throw new Error("Invalid action descriptor, `id`, `label` and `run` are required properties!");if(!this._standaloneKeybindingService)return console.warn("Cannot add keybinding because the editor is configured with an unrecognized KeybindingService"),l.jG.None;const t=e.id,i=e.label,s=ie.M$.and(ie.M$.equals("editorId",this.getId()),ie.M$.deserialize(e.precondition)),n=e.keybindings,r=ie.M$.and(s,ie.M$.deserialize(e.keybindingContext)),o=e.contextMenuGroupId||null,a=e.contextMenuOrder||0,c=(t,...i)=>Promise.resolve(e.run(this,...i)),h=new l.Cm,d=this.getId()+":"+t;if(h.add(St.w.registerCommand(d,c)),o){const e={command:{id:d,title:i},when:s,group:o,order:a};h.add(ni.ZG.appendMenuItem(ni.D8.EditorContext,e))}if(Array.isArray(n))for(const l of n)h.add(this._standaloneKeybindingService.addDynamicKeybinding(d,l,c,r));const u=new yo.f(d,i,i,void 0,s,((...t)=>Promise.resolve(e.run(this,...t))),this._contextKeyService);return this._actions.set(t,u),h.add((0,l.s)((()=>{this._actions.delete(t)}))),h}_triggerCommand(e,t){if(this._codeEditorService instanceof oe)try{this._codeEditorService.setActiveCodeEditor(this),super._triggerCommand(e,t)}finally{this._codeEditorService.setActiveCodeEditor(null)}else super._triggerCommand(e,t)}};No=To([xo(2,ae._Y),xo(3,g.T),xo(4,St.d),xo(5,ie.fN),xo(6,Ie.TN),xo(7,De.b),xo(8,Z.Gy),xo(9,me.Ot),xo(10,Ve.j),xo(11,x.JZ),xo(12,D.ILanguageFeaturesService)],No);let Io=class extends No{constructor(e,t,i,s,n,r,o,a,l,c,h,d,u,g,p,m){const f={...t};Ir(h,f,!1);const _=l.registerEditorContainer(e);"string"===typeof f.theme&&l.setTheme(f.theme),"undefined"!==typeof f.autoDetectHighContrast&&l.setAutoDetectHighContrast(Boolean(f.autoDetectHighContrast));const v=f.model;let C;if(delete f.model,super(e,f,i,s,n,r,o,a,l,c,d,p,m),this._configurationService=h,this._standaloneThemeService=l,this._register(_),"undefined"===typeof v){const e=g.getLanguageIdByMimeType(f.language)||f.language||jr.vH;C=Do(u,g,f.value||"",e,void 0),this._ownsModel=!0}else C=v,this._ownsModel=!1;if(this._attachModel(C),C){const e={oldModelUrl:null,newModelUrl:C.uri};this._onDidChangeModel.fire(e)}}dispose(){super.dispose()}updateOptions(e){Ir(this._configurationService,e,!1),"string"===typeof e.theme&&this._standaloneThemeService.setTheme(e.theme),"undefined"!==typeof e.autoDetectHighContrast&&this._standaloneThemeService.setAutoDetectHighContrast(Boolean(e.autoDetectHighContrast)),super.updateOptions(e)}_postDetachModelCleanup(e){super._postDetachModelCleanup(e),e&&this._ownsModel&&(e.dispose(),this._ownsModel=!1)}};Io=To([xo(2,ae._Y),xo(3,g.T),xo(4,St.d),xo(5,ie.fN),xo(6,Ie.TN),xo(7,De.b),xo(8,Rn.L),xo(9,me.Ot),xo(10,Me.pG),xo(11,Ve.j),xo(12,A.IModelService),xo(13,Ui.L),xo(14,x.JZ),xo(15,D.ILanguageFeaturesService)],Io);let Oo=class extends wo.T{constructor(e,t,i,s,n,r,o,a,l,c,h,d){const u={...t};Ir(a,u,!0);const g=r.registerEditorContainer(e);"string"===typeof u.theme&&r.setTheme(u.theme),"undefined"!==typeof u.autoDetectHighContrast&&r.setAutoDetectHighContrast(Boolean(u.autoDetectHighContrast)),super(e,u,{},s,i,n,d,c),this._configurationService=a,this._standaloneThemeService=r,this._register(g)}dispose(){super.dispose()}updateOptions(e){Ir(this._configurationService,e,!0),"string"===typeof e.theme&&this._standaloneThemeService.setTheme(e.theme),"undefined"!==typeof e.autoDetectHighContrast&&this._standaloneThemeService.setAutoDetectHighContrast(Boolean(e.autoDetectHighContrast)),super.updateOptions(e)}_createInnerEditor(e,t,i){return e.createInstance(No,t,i)}getOriginalEditor(){return super.getOriginalEditor()}getModifiedEditor(){return super.getModifiedEditor()}addCommand(e,t,i){return this.getModifiedEditor().addCommand(e,t,i)}createContextKey(e,t){return this.getModifiedEditor().createContextKey(e,t)}addAction(e){return this.getModifiedEditor().addAction(e)}};function Do(e,t,i,s,n){if(i=i||"",!s){const s=i.indexOf("\n");let r=i;return-1!==s&&(r=i.substring(0,s)),Mo(e,i,t.createByFilepathOrFirstLine(n||null,r),n)}return Mo(e,i,t.createById(s),n)}function Mo(e,t,i,s){return e.createModel(t,i,s)}Oo=To([xo(2,ae._Y),xo(3,ie.fN),xo(4,g.T),xo(5,Rn.L),xo(6,me.Ot),xo(7,Me.pG),xo(8,Oe.Z),xo(9,$t.N8),xo(10,Fn.h),xo(11,gr.Nt)],Oo);var Po=i(41127),Fo=i(46041),Uo=i(49154),Ho=i(49353),Bo=i(92368),Wo=i(74444),Vo=i(75326),zo=i(60002),Go=i(38844),jo=i(65644),Ko=i(25791),Yo=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},qo=function(e,t){return function(i,s){t(i,s,e)}};class $o{constructor(e,t){this.viewModel=e,this.deltaScrollVertical=t}getId(){return this.viewModel}}let Qo=class extends l.jG{constructor(e,t,i,s,n){super(),this._container=e,this._overflowWidgetsDomNode=t,this._workbenchUIElementFactory=i,this._instantiationService=s,this._viewModel=(0,Uo.FY)(this,void 0),this._collapsed=(0,Bs.un)(this,(e=>this._viewModel.read(e)?.collapsed.read(e))),this._editorContentHeight=(0,Uo.FY)(this,500),this.contentHeight=(0,Bs.un)(this,(e=>(this._collapsed.read(e)?0:this._editorContentHeight.read(e))+this._outerEditorHeight)),this._modifiedContentWidth=(0,Uo.FY)(this,0),this._modifiedWidth=(0,Uo.FY)(this,0),this._originalContentWidth=(0,Uo.FY)(this,0),this._originalWidth=(0,Uo.FY)(this,0),this.maxScroll=(0,Bs.un)(this,(e=>{const t=this._modifiedContentWidth.read(e)-this._modifiedWidth.read(e),i=this._originalContentWidth.read(e)-this._originalWidth.read(e);return t>i?{maxScroll:t,width:this._modifiedWidth.read(e)}:{maxScroll:i,width:this._originalWidth.read(e)}})),this._elements=(0,U.h)("div.multiDiffEntry",[(0,U.h)("div.header@header",[(0,U.h)("div.header-content",[(0,U.h)("div.collapse-button@collapseButton"),(0,U.h)("div.file-path",[(0,U.h)("div.title.modified.show-file-icons@primaryPath",[]),(0,U.h)("div.status.deleted@status",["R"]),(0,U.h)("div.title.original.show-file-icons@secondaryPath",[])]),(0,U.h)("div.actions@actions")])]),(0,U.h)("div.editorParent",[(0,U.h)("div.editorContainer@editor")])]),this.editor=this._register(this._instantiationService.createInstance(wo.T,this._elements.editor,{overflowWidgetsDomNode:this._overflowWidgetsDomNode},{})),this.isModifedFocused=(0,Go.Ud)(this.editor.getModifiedEditor()).isFocused,this.isOriginalFocused=(0,Go.Ud)(this.editor.getOriginalEditor()).isFocused,this.isFocused=(0,Bs.un)(this,(e=>this.isModifedFocused.read(e)||this.isOriginalFocused.read(e))),this._resourceLabel=this._workbenchUIElementFactory.createResourceLabel?this._register(this._workbenchUIElementFactory.createResourceLabel(this._elements.primaryPath)):void 0,this._resourceLabel2=this._workbenchUIElementFactory.createResourceLabel?this._register(this._workbenchUIElementFactory.createResourceLabel(this._elements.secondaryPath)):void 0,this._dataStore=this._register(new l.Cm),this._headerHeight=40,this._lastScrollTop=-1,this._isSettingScrollTop=!1;const r=new bs.$(this._elements.collapseButton,{});this._register((0,Bs.fm)((e=>{r.element.className="",r.icon=this._collapsed.read(e)?di.W.chevronRight:di.W.chevronDown}))),this._register(r.onDidClick((()=>{this._viewModel.get()?.collapsed.set(!this._collapsed.get(),void 0)}))),this._register((0,Bs.fm)((e=>{this._elements.editor.style.display=this._collapsed.read(e)?"none":"block"}))),this._register(this.editor.getModifiedEditor().onDidLayoutChange((e=>{const t=this.editor.getModifiedEditor().getLayoutInfo().contentWidth;this._modifiedWidth.set(t,void 0)}))),this._register(this.editor.getOriginalEditor().onDidLayoutChange((e=>{const t=this.editor.getOriginalEditor().getLayoutInfo().contentWidth;this._originalWidth.set(t,void 0)}))),this._register(this.editor.onDidContentSizeChange((e=>{(0,Uo.YY)((t=>{this._editorContentHeight.set(e.contentHeight,t),this._modifiedContentWidth.set(this.editor.getModifiedEditor().getContentWidth(),t),this._originalContentWidth.set(this.editor.getOriginalEditor().getContentWidth(),t)}))}))),this._register(this.editor.getOriginalEditor().onDidScrollChange((e=>{if(this._isSettingScrollTop)return;if(!e.scrollTopChanged||!this._data)return;const t=e.scrollTop-this._lastScrollTop;this._data.deltaScrollVertical(t)}))),this._register((0,Bs.fm)((e=>{const t=this._viewModel.read(e)?.isActive.read(e);this._elements.root.classList.toggle("active",t)}))),this._container.appendChild(this._elements.root),this._outerEditorHeight=this._headerHeight,this._contextKeyService=this._register(n.createScoped(this._elements.actions));const o=this._register(this._instantiationService.createChild(new ir.a([ie.fN,this._contextKeyService])));this._register(o.createInstance(jo.m,this._elements.actions,ni.D8.MultiDiffEditorFileToolbar,{actionRunner:this._register(new Ko.I((()=>this._viewModel.get()?.modifiedUri))),menuOptions:{shouldForwardArgs:!0},toolbarOptions:{primaryGroup:e=>e.startsWith("navigation")},actionViewItemProvider:(e,t)=>(0,si.rN)(o,e,t)}))}setScrollLeft(e){this._modifiedContentWidth.get()-this._modifiedWidth.get()>this._originalContentWidth.get()-this._originalWidth.get()?this.editor.getModifiedEditor().setScrollLeft(e):this.editor.getOriginalEditor().setScrollLeft(e)}setData(e){function t(e){return{...e,scrollBeyondLastLine:!1,hideUnchangedRegions:{enabled:!0},scrollbar:{vertical:"hidden",horizontal:"hidden",handleMouseWheel:!1,useShadows:!1},renderOverviewRuler:!1,fixedOverflowWidgets:!0,overviewRulerBorder:!1}}if(this._data=e,!e)return void(0,Uo.YY)((e=>{this._viewModel.set(void 0,e),this.editor.setDiffModel(null,e),this._dataStore.clear()}));const i=e.viewModel.documentDiffItem;if((0,Uo.YY)((s=>{this._resourceLabel?.setUri(e.viewModel.modifiedUri??e.viewModel.originalUri,{strikethrough:void 0===e.viewModel.modifiedUri});let n=!1,r=!1,o=!1,a="";e.viewModel.modifiedUri&&e.viewModel.originalUri&&e.viewModel.modifiedUri.path!==e.viewModel.originalUri.path?(a="R",n=!0):e.viewModel.modifiedUri?e.viewModel.originalUri||(a="A",o=!0):(a="D",r=!0),this._elements.status.classList.toggle("renamed",n),this._elements.status.classList.toggle("deleted",r),this._elements.status.classList.toggle("added",o),this._elements.status.innerText=a,this._resourceLabel2?.setUri(n?e.viewModel.originalUri:void 0,{strikethrough:!0}),this._dataStore.clear(),this._viewModel.set(e.viewModel,s),this.editor.setDiffModel(e.viewModel.diffEditorViewModelRef,s),this.editor.updateOptions(t(i.options??{}))})),i.onOptionsDidChange&&this._dataStore.add(i.onOptionsDidChange((()=>{this.editor.updateOptions(t(i.options??{}))}))),e.viewModel.isAlive.recomputeInitiallyAndOnChange(this._dataStore,(e=>{e||this.setData(void 0)})),e.viewModel.documentDiffItem.contextKeys)for(const[s,n]of Object.entries(e.viewModel.documentDiffItem.contextKeys))this._contextKeyService.createKey(s,n)}render(e,t,i,s){this._elements.root.style.visibility="visible",this._elements.root.style.top=`${e.start}px`,this._elements.root.style.height=`${e.length}px`,this._elements.root.style.width=`${t}px`,this._elements.root.style.position="absolute";const n=e.length-this._headerHeight,r=Math.max(0,Math.min(s.start-e.start,n));this._elements.header.style.transform=`translateY(${r}px)`,(0,Uo.YY)((i=>{this.editor.layout({width:t-16-2,height:e.length-this._outerEditorHeight})}));try{this._isSettingScrollTop=!0,this._lastScrollTop=i,this.editor.getOriginalEditor().setScrollTop(i)}finally{this._isSettingScrollTop=!1}this._elements.header.classList.toggle("shadow",r>0||i>0),this._elements.header.classList.toggle("collapsed",r===n)}hide(){this._elements.root.style.top="-100000px",this._elements.root.style.visibility="hidden"}};Qo=Yo([qo(3,ae._Y),qo(4,ie.fN)],Qo);class Xo{constructor(e){this._create=e,this._unused=new Set,this._used=new Set,this._itemData=new Map}getUnusedObj(e){let t;if(0===this._unused.size)t=this._create(e),this._itemData.set(t,e);else{const i=[...this._unused.values()];t=i.find((t=>this._itemData.get(t).getId()===e.getId()))??i[0],this._unused.delete(t),this._itemData.set(t,e),t.setData(e)}return this._used.add(t),{object:t,dispose:()=>{this._used.delete(t),this._unused.size>5?t.dispose():this._unused.add(t)}}}dispose(){for(const e of this._used)e.dispose();for(const e of this._unused)e.dispose();this._used.clear(),this._unused.clear()}}var Zo=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Jo=function(e,t){return function(i,s){t(i,s,e)}};let ea=class extends l.jG{constructor(e,t,i,s,n,r){super(),this._element=e,this._dimension=t,this._viewModel=i,this._workbenchUIElementFactory=s,this._parentContextKeyService=n,this._parentInstantiationService=r,this._scrollableElements=(0,U.h)("div.scrollContent",[(0,U.h)("div@content",{style:{overflow:"hidden"}}),(0,U.h)("div.monaco-editor@overflowWidgetsDomNode",{})]),this._scrollable=this._register(new Ho.yE({forceIntegerValues:!1,scheduleAtNextAnimationFrame:e=>(0,U.PG)((0,U.zk)(this._element),e),smoothScrollDuration:100})),this._scrollableElement=this._register(new hi.oO(this._scrollableElements.root,{vertical:1,horizontal:1,useShadows:!1},this._scrollable)),this._elements=(0,U.h)("div.monaco-component.multiDiffEditor",{},[(0,U.h)("div",{},[this._scrollableElement.getDomNode()]),(0,U.h)("div.placeholder@placeholder",{},[(0,U.h)("div",[(0,E.kg)("noChangedFiles","No Changed Files")])])]),this._sizeObserver=this._register(new Bo.pN(this._element,void 0)),this._objectPool=this._register(new Xo((e=>{const t=this._instantiationService.createInstance(Qo,this._scrollableElements.content,this._scrollableElements.overflowWidgetsDomNode,this._workbenchUIElementFactory);return t.setData(e),t}))),this.scrollTop=(0,Bs.y0)(this,this._scrollableElement.onScroll,(()=>this._scrollableElement.getScrollPosition().scrollTop)),this.scrollLeft=(0,Bs.y0)(this,this._scrollableElement.onScroll,(()=>this._scrollableElement.getScrollPosition().scrollLeft)),this._viewItemsInfo=(0,Bs.rm)(this,((e,t)=>{const i=this._viewModel.read(e);if(!i)return{items:[],getItem:e=>{throw new v.D7}};const s=i.items.read(e),n=new Map;return{items:s.map((e=>{const i=t.add(new ta(e,this._objectPool,this.scrollLeft,(e=>{this._scrollableElement.setScrollPosition({scrollTop:this._scrollableElement.getScrollPosition().scrollTop+e})}))),s=this._lastDocStates?.[i.getKey()];return s&&(0,Uo.Rn)((e=>{i.setViewState(s,e)})),n.set(e,i),i})),getItem:e=>n.get(e)}})),this._viewItems=this._viewItemsInfo.map(this,(e=>e.items)),this._spaceBetweenPx=0,this._totalHeight=this._viewItems.map(this,((e,t)=>e.reduce(((e,i)=>e+i.contentHeight.read(t)+this._spaceBetweenPx),0))),this._contextKeyService=this._register(this._parentContextKeyService.createScoped(this._element)),this._instantiationService=this._register(this._parentInstantiationService.createChild(new ir.a([ie.fN,this._contextKeyService]))),this._lastDocStates={},this._contextKeyService.createKey(zo.R.inMultiDiffEditor.key,!0),this._register((0,Bs.yC)(((e,t)=>{const i=this._viewModel.read(e);if(i&&i.contextKeys)for(const[s,n]of Object.entries(i.contextKeys)){const e=this._contextKeyService.createKey(s,void 0);e.set(n),t.add((0,l.s)((()=>e.reset())))}})));const o=this._parentContextKeyService.createKey(zo.R.multiDiffEditorAllCollapsed.key,!1);this._register((0,Bs.fm)((e=>{const t=this._viewModel.read(e);if(t){const i=t.items.read(e).every((t=>t.collapsed.read(e)));o.set(i)}}))),this._register((0,Bs.fm)((e=>{const t=this._dimension.read(e);this._sizeObserver.observe(t)}))),this._register((0,Bs.fm)((e=>{const t=this._viewItems.read(e);this._elements.placeholder.classList.toggle("visible",0===t.length)}))),this._scrollableElements.content.style.position="relative",this._register((0,Bs.fm)((e=>{const t=this._sizeObserver.height.read(e);this._scrollableElements.root.style.height=`${t}px`;const i=this._totalHeight.read(e);this._scrollableElements.content.style.height=`${i}px`;const s=this._sizeObserver.width.read(e);let n=s;const r=this._viewItems.read(e),o=(0,Fo.Cn)(r,(0,b.VE)((t=>t.maxScroll.read(e).maxScroll),b.U9));if(o){n=s+o.maxScroll.read(e).maxScroll}this._scrollableElement.setScrollDimensions({width:s,height:t,scrollHeight:i,scrollWidth:n})}))),e.replaceChildren(this._elements.root),this._register((0,l.s)((()=>{e.replaceChildren()}))),this._register(this._register((0,Bs.fm)((e=>{(0,Uo.YY)((t=>{this.render(e)}))}))))}render(e){const t=this.scrollTop.read(e);let i=0,s=0,n=0;const r=this._sizeObserver.height.read(e),o=Wo.L.ofStartAndLength(t,r),a=this._sizeObserver.width.read(e);for(const l of this._viewItems.read(e)){const c=l.contentHeight.read(e),h=Math.min(c,r),d=Wo.L.ofStartAndLength(s,h),u=Wo.L.ofStartAndLength(n,c);if(u.isBefore(o))i-=c-h,l.hide();else if(u.isAfter(o))l.hide();else{const e=Math.max(0,Math.min(o.start-u.start,c-h));i-=e;const s=Wo.L.ofStartAndLength(t+i,r);l.render(d,e,a,s)}s+=h+this._spaceBetweenPx,n+=c+this._spaceBetweenPx}this._scrollableElements.content.style.transform=`translateY(${-(t+i)}px)`}};ea=Zo([Jo(4,ie.fN),Jo(5,ae._Y)],ea);class ta extends l.jG{constructor(e,t,i,s){super(),this.viewModel=e,this._objectPool=t,this._scrollLeft=i,this._deltaScrollVertical=s,this._templateRef=this._register((0,Uo.X2)(this,void 0)),this.contentHeight=(0,Bs.un)(this,(e=>this._templateRef.read(e)?.object.contentHeight?.read(e)??this.viewModel.lastTemplateData.read(e).contentHeight)),this.maxScroll=(0,Bs.un)(this,(e=>this._templateRef.read(e)?.object.maxScroll.read(e)??{maxScroll:0,scrollWidth:0})),this.template=(0,Bs.un)(this,(e=>this._templateRef.read(e)?.object)),this._isHidden=(0,Bs.FY)(this,!1),this._isFocused=(0,Bs.un)(this,(e=>this.template.read(e)?.isFocused.read(e)??!1)),this.viewModel.setIsFocused(this._isFocused,void 0),this._register((0,Bs.fm)((e=>{const t=this._scrollLeft.read(e);this._templateRef.read(e)?.object.setScrollLeft(t)}))),this._register((0,Bs.fm)((e=>{const t=this._templateRef.read(e);if(!t)return;if(!this._isHidden.read(e))return;t.object.isFocused.read(e)||this._clear()})))}dispose(){this._clear(),super.dispose()}toString(){return`VirtualViewItem(${this.viewModel.documentDiffItem.modified?.uri.toString()})`}getKey(){return this.viewModel.getKey()}setViewState(e,t){this.viewModel.collapsed.set(e.collapsed,t),this._updateTemplateData(t);const i=this.viewModel.lastTemplateData.get(),s=e.selections?.map(Vo.L.liftSelection);this.viewModel.lastTemplateData.set({...i,selections:s},t);const n=this._templateRef.get();n&&s&&n.object.editor.setSelections(s)}_updateTemplateData(e){const t=this._templateRef.get();t&&this.viewModel.lastTemplateData.set({contentHeight:t.object.contentHeight.get(),selections:t.object.editor.getSelections()??void 0},e)}_clear(){const e=this._templateRef.get();e&&(0,Uo.Rn)((t=>{this._updateTemplateData(t),e.object.hide(),this._templateRef.set(void 0,t)}))}hide(){this._isHidden.set(!0,void 0)}render(e,t,i,s){this._isHidden.set(!1,void 0);let n=this._templateRef.get();if(!n){n=this._objectPool.getUnusedObj(new $o(this.viewModel,this._deltaScrollVertical)),this._templateRef.set(n,void 0);const e=this.viewModel.lastTemplateData.get().selections;e&&n.object.editor.setSelections(e)}n.object.render(e,i,t,s)}}(0,Ne.x1A)("multiDiffEditor.headerBackground",{dark:"#262626",light:"tab.inactiveBackground",hcDark:"tab.inactiveBackground",hcLight:"tab.inactiveBackground"},(0,E.kg)("multiDiffEditor.headerBackground","The background color of the diff editor's header")),(0,Ne.x1A)("multiDiffEditor.background",Ne.YtV,(0,E.kg)("multiDiffEditor.background","The background color of the multi file diff editor")),(0,Ne.x1A)("multiDiffEditor.border",{dark:"sideBarSectionHeader.border",light:"#cccccc",hcDark:"sideBarSectionHeader.border",hcLight:"#cccccc"},(0,E.kg)("multiDiffEditor.border","The border color of the multi file diff editor"));var ia=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},sa=function(e,t){return function(i,s){t(i,s,e)}};let na=class extends l.jG{constructor(e,t,i){super(),this._element=e,this._workbenchUIElementFactory=t,this._instantiationService=i,this._dimension=(0,Bs.FY)(this,void 0),this._viewModel=(0,Bs.FY)(this,void 0),this._widgetImpl=(0,Bs.rm)(this,((e,t)=>((0,Po.b)(Qo,e),t.add(this._instantiationService.createInstance((0,Po.b)(ea,e),this._element,this._dimension,this._viewModel,this._workbenchUIElementFactory))))),this._register((0,Bs.OI)(this._widgetImpl))}};function ra(e,t,i){return Hr.initialize(i||{}).createInstance(Io,e,t)}function oa(e){return Hr.get(g.T).onCodeEditorAdd((t=>{e(t)}))}function aa(e){return Hr.get(g.T).onDiffEditorAdd((t=>{e(t)}))}function la(){return Hr.get(g.T).listCodeEditors()}function ca(){return Hr.get(g.T).listDiffEditors()}function ha(e,t,i){return Hr.initialize(i||{}).createInstance(Oo,e,t)}function da(e,t){const i=Hr.initialize(t||{});return new na(e,{},i)}function ua(e){if("string"!==typeof e.id||"function"!==typeof e.run)throw new Error("Invalid command descriptor, `id` and `run` are required properties!");return St.w.registerCommand(e.id,e.run)}function ga(e){if("string"!==typeof e.id||"string"!==typeof e.label||"function"!==typeof e.run)throw new Error("Invalid action descriptor, `id`, `label` and `run` are required properties!");const t=ie.M$.deserialize(e.precondition),i=new l.Cm;if(i.add(St.w.registerCommand(e.id,((i,...s)=>u.DX.runEditorCommand(i,s,t,((t,i,s)=>Promise.resolve(e.run(i,...s))))))),e.contextMenuGroupId){const s={command:{id:e.id,title:e.label},when:t,group:e.contextMenuGroupId,order:e.contextMenuOrder||0};i.add(ni.ZG.appendMenuItem(ni.D8.EditorContext,s))}if(Array.isArray(e.keybindings)){const s=Hr.get(De.b);if(s instanceof Lr){const n=ie.M$.and(t,ie.M$.deserialize(e.keybindingContext));i.add(s.addDynamicKeybindings(e.keybindings.map((t=>({keybinding:t,command:e.id,when:n})))))}else console.warn("Cannot add keybinding because the editor is configured with an unrecognized KeybindingService")}return i}function pa(e){return ma([e])}function ma(e){const t=Hr.get(De.b);return t instanceof Lr?t.addDynamicKeybindings(e.map((e=>({keybinding:e.keybinding,command:e.command,commandArgs:e.commandArgs,when:ie.M$.deserialize(e.when)})))):(console.warn("Cannot add keybinding because the editor is configured with an unrecognized KeybindingService"),l.jG.None)}function fa(e,t,i){const s=Hr.get(Ui.L),n=s.getLanguageIdByMimeType(t)||t;return Do(Hr.get(A.IModelService),s,e,n,i)}function _a(e,t){const i=Hr.get(Ui.L),s=i.getLanguageIdByMimeType(t)||t||jr.vH;e.setLanguage(i.createById(s))}function va(e,t,i){if(e){Hr.get(or.DR).changeOne(t,e.uri,i)}}function Ca(e){Hr.get(or.DR).changeAll(e,[])}function ba(e){return Hr.get(or.DR).read(e)}function Ea(e){return Hr.get(or.DR).onMarkerChanged(e)}function Sa(e){return Hr.get(A.IModelService).getModel(e)}function ya(){return Hr.get(A.IModelService).getModels()}function wa(e){return Hr.get(A.IModelService).onModelAdded(e)}function La(e){return Hr.get(A.IModelService).onModelRemoved(e)}function Ra(e){return Hr.get(A.IModelService).onModelLanguageChanged((t=>{e({model:t.model,oldLanguage:t.oldLanguageId})}))}function Ta(e){return function(e,t){return new Br(e,t)}(Hr.get(A.IModelService),e)}function xa(e,t){const i=Hr.get(Ui.L),s=Hr.get(Rn.L);return Eo.colorizeElement(s,i,e,t).then((()=>{s.registerEditorContainer(e)}))}function ka(e,t,i){const s=Hr.get(Ui.L);return Hr.get(Rn.L).registerEditorContainer(a.G.document.body),Eo.colorize(s,e,t,i)}function Aa(e,t,i=4){return Hr.get(Rn.L).registerEditorContainer(a.G.document.body),Eo.colorizeModelLine(e,t,i)}function Na(e,t){Gr.dG.getOrCreate(t);const i=function(e){const t=Gr.dG.get(e);return t||{getInitialState:()=>Kr.r3,tokenize:(t,i,s)=>(0,Kr.$H)(e,s)}}(t),s=(0,c.uz)(e),n=[];let r=i.getInitialState();for(let o=0,a=s.length;o("string"===typeof t&&(t=h.r.parse(t)),e.open(t))})}function Fa(e){return Hr.get(g.T).registerCodeEditorOpenHandler((async(t,i,s)=>{if(!i)return null;const n=t.options?.selection;let r;return n&&"number"===typeof n.endLineNumber&&"number"===typeof n.endColumn?r=n:n&&(r={lineNumber:n.startLineNumber,column:n.startColumn}),await e.openCodeEditor(i,t.resource,r)?i:null}))}na=ia([sa(2,ae._Y)],na);var Ua=i(47661);function Ha(e,t){return"boolean"===typeof e?e:t}function Ba(e,t){return"string"===typeof e?e:t}function Wa(e,t=!1){t&&(e=e.map((function(e){return e.toLowerCase()})));const i=function(e){const t={};for(const i of e)t[i]=!0;return t}(e);return t?function(e){return void 0!==i[e.toLowerCase()]&&i.hasOwnProperty(e.toLowerCase())}:function(e){return void 0!==i[e]&&i.hasOwnProperty(e)}}function Va(e,t,i){t=t.replace(/@@/g,"\x01");let s,n=0;do{s=!1,t=t.replace(/@(\w+)/g,(function(i,n){s=!0;let r="";if("string"===typeof e[n])r=e[n];else{if(!(e[n]&&e[n]instanceof RegExp))throw void 0===e[n]?no(e,"language definition does not contain attribute '"+n+"', used at: "+t):no(e,"attribute reference '"+n+"' must be a string, used at: "+t);r=e[n].source}return to(r)?"":"(?:"+r+")"})),n++}while(s&&n<5);t=t.replace(/\x01/g,"@");const r=(e.ignoreCase?"i":"")+(e.unicode?"u":"");if(i){if(t.match(/\$[sS](\d\d?)/g)){let i=null,s=null;return n=>(s&&i===n||(i=n,s=new RegExp(function(e,t,i){let s=null;return t.replace(/\$[sS](\d\d?)/g,(function(t,n){return null===s&&(s=i.split("."),s.unshift(i)),!to(n)&&n=100){s-=100;const e=i.split(".");if(e.unshift(i),s=0&&(s.tokenSubst=!0),"string"===typeof i.bracket)if("@open"===i.bracket)s.bracket=1;else{if("@close"!==i.bracket)throw no(e,"a 'bracket' attribute must be either '@open' or '@close', in rule: "+t);s.bracket=-1}if(i.next){if("string"!==typeof i.next)throw no(e,"the next state must be a string value in rule: "+t);{let n=i.next;if(!/^(@pop|@push|@popall)$/.test(n)&&("@"===n[0]&&(n=n.substr(1)),n.indexOf("$")<0&&!function(e,t){let i=t;for(;i&&i.length>0;){if(e.stateNames[i])return!0;const t=i.lastIndexOf(".");i=t<0?null:i.substr(0,t)}return!1}(e,ro(e,n,"",[],""))))throw no(e,"the next state '"+i.next+"' is not defined in rule: "+t);s.next=n}}return"number"===typeof i.goBack&&(s.goBack=i.goBack),"string"===typeof i.switchTo&&(s.switchTo=i.switchTo),"string"===typeof i.log&&(s.log=i.log),"string"===typeof i.nextEmbedded&&(s.nextEmbedded=i.nextEmbedded,e.usesEmbedded=!0),s}}if(Array.isArray(i)){const s=[];for(let n=0,r=i.length;n0&&"^"===i[0],this.name=this.name+": "+i,this.regex=Va(e,"^(?:"+(this.matchOnlyAtLineStart?i.substr(1):i)+")",!0)}setAction(e,t){this.action=Ga(e,this.name,t)}resolveRegex(e){return this.regex instanceof RegExp?this.regex:this.regex(e)}}function Ka(e,t){if(!t||"object"!==typeof t)throw new Error("Monarch: expecting a language definition object");const i={languageId:e,includeLF:Ha(t.includeLF,!1),noThrow:!1,maxStack:100,start:"string"===typeof t.start?t.start:null,ignoreCase:Ha(t.ignoreCase,!1),unicode:Ha(t.unicode,!1),tokenPostfix:Ba(t.tokenPostfix,"."+e),defaultToken:Ba(t.defaultToken,"source"),usesEmbedded:!1,stateNames:{},tokenizer:{},brackets:[]},s=t;function n(e,r,o){for(const a of o){let o=a.include;if(o){if("string"!==typeof o)throw no(i,"an 'include' attribute must be a string at: "+e);if("@"===o[0]&&(o=o.substr(1)),!t.tokenizer[o])throw no(i,"include target '"+o+"' is not defined at: "+e);n(e+"."+o,r,t.tokenizer[o])}else{const t=new ja(e);if(Array.isArray(a)&&a.length>=1&&a.length<=3)if(t.setRegex(s,a[0]),a.length>=3)if("string"===typeof a[1])t.setAction(s,{token:a[1],next:a[2]});else{if("object"!==typeof a[1])throw no(i,"a next state as the last element of a rule can only be given if the action is either an object or a string, at: "+e);{const e=a[1];e.next=a[2],t.setAction(s,e)}}else t.setAction(s,a[1]);else{if(!a.regex)throw no(i,"a rule must either be an array, or an object with a 'regex' or 'include' field at: "+e);a.name&&"string"===typeof a.name&&(t.name=a.name),a.matchOnlyAtStart&&(t.matchOnlyAtLineStart=Ha(a.matchOnlyAtLineStart,!1)),t.setRegex(s,a.regex),t.setAction(s,a.action)}r.push(t)}}}if(s.languageId=e,s.includeLF=i.includeLF,s.ignoreCase=i.ignoreCase,s.unicode=i.unicode,s.noThrow=i.noThrow,s.usesEmbedded=i.usesEmbedded,s.stateNames=t.tokenizer,s.defaultToken=i.defaultToken,!t.tokenizer||"object"!==typeof t.tokenizer)throw no(i,"a language definition must define the 'tokenizer' attribute as an object");i.tokenizer=[];for(const o in t.tokenizer)if(t.tokenizer.hasOwnProperty(o)){i.start||(i.start=o);const e=t.tokenizer[o];i.tokenizer[o]=new Array,n("tokenizer."+o,i.tokenizer[o],e)}if(i.usesEmbedded=s.usesEmbedded,t.brackets){if(!Array.isArray(t.brackets))throw no(i,"the 'brackets' attribute must be defined as an array")}else t.brackets=[{open:"{",close:"}",token:"delimiter.curly"},{open:"[",close:"]",token:"delimiter.square"},{open:"(",close:")",token:"delimiter.parenthesis"},{open:"<",close:">",token:"delimiter.angle"}];const r=[];for(const o of t.brackets){let e=o;if(e&&Array.isArray(e)&&3===e.length&&(e={token:e[2],open:e[0],close:e[1]}),e.open===e.close)throw no(i,"open and close brackets in a 'brackets' attribute must be different: "+e.open+"\n hint: use the 'bracket' attribute if matching on equal brackets is required.");if("string"!==typeof e.open||"string"!==typeof e.token||"string"!==typeof e.close)throw no(i,"every element in the 'brackets' array must be a '{open,close,token}' object or array");r.push({token:e.token+i.tokenPostfix,open:io(i,e.open),close:io(i,e.close)})}return i.brackets=r,i.noThrow=!0,i}function Ya(e){jr.W6.registerLanguage(e)}function qa(){let e=[];return e=e.concat(jr.W6.getLanguages()),e}function $a(e){return Hr.get(Ui.L).languageIdCodec.encodeLanguageId(e)}function Qa(e,t){return Hr.withServices((()=>{const i=Hr.get(Ui.L).onDidRequestRichLanguageFeatures((s=>{s===e&&(i.dispose(),t())}));return i}))}function Xa(e,t){return Hr.withServices((()=>{const i=Hr.get(Ui.L).onDidRequestBasicLanguageFeatures((s=>{s===e&&(i.dispose(),t())}));return i}))}function Za(e,t){if(!Hr.get(Ui.L).isRegisteredLanguageId(e))throw new Error(`Cannot set configuration for unknown language ${e}`);return Hr.get(x.JZ).register(e,t,100)}class Ja{constructor(e,t){this._languageId=e,this._actual=t}dispose(){}getInitialState(){return this._actual.getInitialState()}tokenize(e,t,i){if("function"===typeof this._actual.tokenize)return el.adaptTokenize(this._languageId,this._actual,e,i);throw new Error("Not supported!")}tokenizeEncoded(e,t,i){const s=this._actual.tokenizeEncoded(e,i);return new Gr.rY(s.tokens,s.endState)}}class el{constructor(e,t,i,s){this._languageId=e,this._actual=t,this._languageService=i,this._standaloneThemeService=s}dispose(){}getInitialState(){return this._actual.getInitialState()}static _toClassicTokens(e,t){const i=[];let s=0;for(let n=0,r=e.length;n0&&n[r-1]===a)continue;let c=e.startIndex;0===l?c=0:c{const i=await Promise.resolve(t.create());return i?"function"===typeof i.getInitialState?sl(e,i):new vo(Hr.get(Ui.L),Hr.get(Rn.L),e,Ka(e,i),Hr.get(Me.pG)):null}));return Gr.dG.registerFactory(e,i)}function rl(e,t){if(!Hr.get(Ui.L).isRegisteredLanguageId(e))throw new Error(`Cannot set tokens provider for unknown language ${e}`);return tl(t)?nl(e,{create:()=>t}):Gr.dG.register(e,sl(e,t))}function ol(e,t){return tl(t)?nl(e,{create:()=>t}):Gr.dG.register(e,(t=>new vo(Hr.get(Ui.L),Hr.get(Rn.L),e,Ka(e,t),Hr.get(Me.pG)))(t))}function al(e,t){return Hr.get(D.ILanguageFeaturesService).referenceProvider.register(e,t)}function ll(e,t){return Hr.get(D.ILanguageFeaturesService).renameProvider.register(e,t)}function cl(e,t){return Hr.get(D.ILanguageFeaturesService).newSymbolNamesProvider.register(e,t)}function hl(e,t){return Hr.get(D.ILanguageFeaturesService).signatureHelpProvider.register(e,t)}function dl(e,t){return Hr.get(D.ILanguageFeaturesService).hoverProvider.register(e,{provideHover:async(e,i,s,n)=>{const r=e.getWordAtPosition(i);return Promise.resolve(t.provideHover(e,i,s,n)).then((e=>{if(e)return!e.range&&r&&(e.range=new T.Q(i.lineNumber,r.startColumn,i.lineNumber,r.endColumn)),e.range||(e.range=new T.Q(i.lineNumber,i.column,i.lineNumber,i.column)),e}))}})}function ul(e,t){return Hr.get(D.ILanguageFeaturesService).documentSymbolProvider.register(e,t)}function gl(e,t){return Hr.get(D.ILanguageFeaturesService).documentHighlightProvider.register(e,t)}function pl(e,t){return Hr.get(D.ILanguageFeaturesService).linkedEditingRangeProvider.register(e,t)}function ml(e,t){return Hr.get(D.ILanguageFeaturesService).definitionProvider.register(e,t)}function fl(e,t){return Hr.get(D.ILanguageFeaturesService).implementationProvider.register(e,t)}function _l(e,t){return Hr.get(D.ILanguageFeaturesService).typeDefinitionProvider.register(e,t)}function vl(e,t){return Hr.get(D.ILanguageFeaturesService).codeLensProvider.register(e,t)}function Cl(e,t,i){return Hr.get(D.ILanguageFeaturesService).codeActionProvider.register(e,{providedCodeActionKinds:i?.providedCodeActionKinds,documentation:i?.documentation,provideCodeActions:(e,i,s,n)=>{const r=Hr.get(or.DR).read({resource:e.uri}).filter((e=>T.Q.areIntersectingOrTouching(e,i)));return t.provideCodeActions(e,i,{markers:r,only:s.only,trigger:s.trigger},n)},resolveCodeAction:t.resolveCodeAction})}function bl(e,t){return Hr.get(D.ILanguageFeaturesService).documentFormattingEditProvider.register(e,t)}function El(e,t){return Hr.get(D.ILanguageFeaturesService).documentRangeFormattingEditProvider.register(e,t)}function Sl(e,t){return Hr.get(D.ILanguageFeaturesService).onTypeFormattingEditProvider.register(e,t)}function yl(e,t){return Hr.get(D.ILanguageFeaturesService).linkProvider.register(e,t)}function wl(e,t){return Hr.get(D.ILanguageFeaturesService).completionProvider.register(e,t)}function Ll(e,t){return Hr.get(D.ILanguageFeaturesService).colorProvider.register(e,t)}function Rl(e,t){return Hr.get(D.ILanguageFeaturesService).foldingRangeProvider.register(e,t)}function Tl(e,t){return Hr.get(D.ILanguageFeaturesService).declarationProvider.register(e,t)}function xl(e,t){return Hr.get(D.ILanguageFeaturesService).selectionRangeProvider.register(e,t)}function kl(e,t){return Hr.get(D.ILanguageFeaturesService).documentSemanticTokensProvider.register(e,t)}function Al(e,t){return Hr.get(D.ILanguageFeaturesService).documentRangeSemanticTokensProvider.register(e,t)}function Nl(e,t){return Hr.get(D.ILanguageFeaturesService).inlineCompletionsProvider.register(e,t)}function Il(e,t){return Hr.get(D.ILanguageFeaturesService).inlineEditProvider.register(e,t)}function Ol(e,t){return Hr.get(D.ILanguageFeaturesService).inlayHintsProvider.register(e,t)}var Dl=i(49079);r.qB.wrappingIndent.defaultValue=0,r.qB.glyphMargin.defaultValue=!1,r.qB.autoIndent.defaultValue=3,r.qB.overviewRulerLanes.defaultValue=2,Dl.Pj.setFormatterSelector(((e,t,i)=>Promise.resolve(e[0])));const Ml=(0,o.createMonacoBaseAPI)();Ml.editor={create:ra,getEditors:la,getDiffEditors:ca,onDidCreateEditor:oa,onDidCreateDiffEditor:aa,createDiffEditor:ha,addCommand:ua,addEditorAction:ga,addKeybindingRule:pa,addKeybindingRules:ma,createModel:fa,setModelLanguage:_a,setModelMarkers:va,getModelMarkers:ba,removeAllMarkers:Ca,onDidChangeMarkers:Ea,getModels:ya,getModel:Sa,onDidCreateModel:wa,onWillDisposeModel:La,onDidChangeModelLanguage:Ra,createWebWorker:Ta,colorizeElement:xa,colorize:ka,colorizeModelLine:Aa,tokenize:Na,defineTheme:Ia,setTheme:Oa,remeasureFonts:Da,registerCommand:Ma,registerLinkOpener:Pa,registerEditorOpener:Fa,AccessibilitySupport:qr.Gn,ContentWidgetPositionPreference:qr.Qj,CursorChangeReason:qr.h5,DefaultEndOfLine:qr.of,EditorAutoIndentStrategy:qr.e0,EditorOption:qr.p2,EndOfLinePreference:qr.kf,EndOfLineSequence:qr.WU,MinimapPosition:qr.R3,MinimapSectionHeaderStyle:qr.VX,MouseTargetType:qr.hS,OverlayWidgetPositionPreference:qr.dE,OverviewRulerLane:qr.A5,GlyphMarginLane:qr.ZS,RenderLineNumbersType:qr.DO,RenderMinimap:qr.hW,ScrollbarVisibility:qr.XR,ScrollType:qr.ov,TextEditorCursorBlinkingStyle:qr.U7,TextEditorCursorStyle:qr.m9,TrackedRangeStickiness:qr.kK,WrappingIndent:qr.tJ,InjectedTextCursorStops:qr.VW,PositionAffinity:qr.Ic,ShowLightbulbIconMode:qr.jT,ConfigurationChangedEvent:r.lw,BareFontInfo:Vr._8,FontInfo:Vr.YJ,TextModelResolvedOptions:Yr.X2,FindMatch:Yr.Dg,ApplyUpdateResult:r.hZ,EditorZoom:Wr.D,createMultiFileDiffEditor:da,EditorType:zr._,EditorOptions:r.qB},Ml.languages={register:Ya,getLanguages:qa,onLanguage:Qa,onLanguageEncountered:Xa,getEncodedLanguageId:$a,setLanguageConfiguration:Za,setColorMap:il,registerTokensProviderFactory:nl,setTokensProvider:rl,setMonarchTokensProvider:ol,registerReferenceProvider:al,registerRenameProvider:ll,registerNewSymbolNameProvider:cl,registerCompletionItemProvider:wl,registerSignatureHelpProvider:hl,registerHoverProvider:dl,registerDocumentSymbolProvider:ul,registerDocumentHighlightProvider:gl,registerLinkedEditingRangeProvider:pl,registerDefinitionProvider:ml,registerImplementationProvider:fl,registerTypeDefinitionProvider:_l,registerCodeLensProvider:vl,registerCodeActionProvider:Cl,registerDocumentFormattingEditProvider:bl,registerDocumentRangeFormattingEditProvider:El,registerOnTypeFormattingEditProvider:Sl,registerLinkProvider:yl,registerColorProvider:Ll,registerFoldingRangeProvider:Rl,registerDeclarationProvider:Tl,registerSelectionRangeProvider:xl,registerDocumentSemanticTokensProvider:kl,registerDocumentRangeSemanticTokensProvider:Al,registerInlineCompletionsProvider:Nl,registerInlineEditProvider:Il,registerInlayHintsProvider:Ol,DocumentHighlightKind:qr.Kb,CompletionItemKind:qr.Io,CompletionItemTag:qr.QP,CompletionItemInsertTextRule:qr._E,SymbolKind:qr.v0,SymbolTag:qr.H_,IndentAction:qr.l,CompletionTriggerKind:qr.t7,SignatureHelpTriggerKind:qr.WA,InlayHintKind:qr.r4,InlineCompletionTriggerKind:qr.qw,InlineEditTriggerKind:qr.sm,CodeActionTriggerType:qr.ok,NewSymbolNameTag:qr.OV,NewSymbolNameTriggerKind:qr.YT,PartialAcceptTriggerKind:qr.Ah,HoverVerbosityAction:qr.M$,FoldingRangeKind:Gr.lO,SelectedSuggestionInfo:Gr.GE};const Pl=Ml.CancellationTokenSource,Fl=Ml.Emitter,Ul=Ml.KeyCode,Hl=Ml.KeyMod,Bl=Ml.Position,Wl=Ml.Range,Vl=Ml.Selection,zl=Ml.SelectionDirection,Gl=Ml.MarkerSeverity,jl=Ml.MarkerTag,Kl=Ml.Uri,Yl=Ml.Token,ql=Ml.editor,$l=Ml.languages,Ql=globalThis.MonacoEnvironment;(Ql?.globalAPI||"function"===typeof define&&i.amdO)&&(globalThis.monaco=Ml),"undefined"!==typeof globalThis.require&&"function"===typeof globalThis.require.config&&globalThis.require.config({ignoreDuplicateModules:["vscode-languageserver-types","vscode-languageserver-types/main","vscode-languageserver-textdocument","vscode-languageserver-textdocument/main","vscode-nls","vscode-nls/vscode-nls","jsonc-parser","jsonc-parser/main","vscode-uri","vscode-uri/index","vs/basic-languages/typescript/typescript"]});var Xl;i(61562),i(94318),i(23304),i(59896),i(75208),i(51232),i(77888),i(46686),i(27020),i(15600),i(80200),i(87152),i(11272),i(60352),i(66235),i(31474),i(84840),i(17184),i(74304),i(74800),i(37954),i(25922),i(46648),i(61082),i(19856),i(97884),i(89518),i(83488),i(3254),i(57680),i(99669),i(796),i(89336),i(19436),i(40340),i(52894),i(86492),i(73374),i(38320),i(92080),i(57664),i(8868),i(31396),i(18544),i(538),i(25064),i(64256),i(32624),i(97360),i(42776),i(97144),i(46304),i(58820),i(82560),i(74276),i(39866),i(73020),i(71316),i(70492),i(50848),i(59520),i(46576),i(49150),i(33358),i(96716),i(28304),i(14720),i(27734),i(2068),i(71468),i(15482),i(42572),i(77668),i(36e3),i(10072),i(48448),i(51376),i(61764),i(85872),i(24152),i(42144),i(22362),i(98408),i(61472),i(50576),i(23934);self.MonacoEnvironment=(Xl={editorWorkerService:"editor.worker.js",css:"css.worker.js",html:"html.worker.js",json:"json.worker.js",typescript:"ts.worker.js",javascript:"ts.worker.js",less:"css.worker.js",scss:"css.worker.js",handlebars:"html.worker.js",razor:"html.worker.js"},{globalAPI:!1,getWorkerUrl:function(e,t){var s=i.p,n=(s?s.replace(/\/$/,"")+"/":"")+Xl[t];if(/^((http:)|(https:)|(file:)|(\/\/))/.test(n)){var r=String(window.location),o=r.substr(0,r.length-window.location.hash.length-window.location.search.length-window.location.pathname.length);if(n.substring(0,o.length)!==o){/^(\/\/)/.test(n)&&(n=window.location.protocol+n);var a=new Blob(["/*"+t+'*/importScripts("'+n+'");'],{type:"application/javascript"});return URL.createObjectURL(a)}}return n}});const Zl=s},67913:(e,t,i)=>{"use strict";i.d(t,{cj:()=>n.MarkerSeverity,EN:()=>n.editor,eo:()=>n.languages});i(44915),i(88952),i(36999),i(58590),i(6438),i(94908),i(4836),i(52555),i(64215),i(31659),i(99822),i(40142),i(18864),i(32516),i(20961),i(40800),i(2183),i(58568),i(63867),i(61731),i(34175),i(44588),i(70552),i(48279),i(65877),i(81091),i(99312),i(62427),i(58466),i(56800),i(28449),i(57244),i(76440),i(80409),i(58145),i(40677),i(9948),i(84325),i(15040),i(75639),i(85117),i(14614),i(95200),i(50352),i(4519),i(85646),i(77047),i(6429),i(28211),i(59731),i(57377),i(50071),i(18278),i(98745),i(44798),i(10617),i(30936),i(57197),i(90870),i(10846),i(22890),i(98472),i(50166),i(68887),i(47210),i(79907),i(38728),i(46606);var s,n=i(80781);i(61562),i(94318),i(23304),i(59896),i(75208),i(51232),i(77888),i(46686),i(27020),i(15600),i(80200),i(87152),i(60352),i(66235),i(31474),i(84840),i(17184),i(74304),i(37954),i(74800),i(25922),i(46648),i(61082),i(19856),i(97884),i(83488),i(3254),i(57680),i(796),i(89336),i(19436),i(40340),i(86492),i(52894),i(73374),i(38320),i(92080),i(57664),i(8868),i(31396),i(18544),i(538),i(25064),i(64256),i(32624),i(97360),i(42776),i(97144),i(46304),i(58820),i(82560),i(74276),i(39866),i(73020),i(71316),i(70492),i(50848),i(59520),i(46576),i(49150),i(33358),i(96716),i(28304),i(14720),i(27734),i(2068),i(71468),i(15482),i(42572),i(77668),i(36e3),i(10072),i(48448),i(51376),i(61764),i(85872),i(42144),i(22362),i(98408),i(61472),i(50576),i(11272),i(89518),i(99669),i(24152),i(51861),i(97791),i(23934);self.MonacoEnvironment=(s={editorWorkerService:"editor.worker.js",css:"css.worker.js",html:"html.worker.js",json:"json.worker.js",typescript:"ts.worker.js",javascript:"ts.worker.js",less:"css.worker.js",scss:"css.worker.js",handlebars:"html.worker.js",razor:"html.worker.js"},{globalAPI:!1,getWorkerUrl:function(e,t){var n=i.p,r=(n?n.replace(/\/$/,"")+"/":"")+s[t];if(/^((http:)|(https:)|(file:)|(\/\/))/.test(r)){var o=String(window.location),a=o.substr(0,o.length-window.location.hash.length-window.location.search.length-window.location.pathname.length);if(r.substring(0,a.length)!==a){/^(\/\/)/.test(r)&&(r=window.location.protocol+r);var l=new Blob(["/*"+t+'*/importScripts("'+r+'");'],{type:"application/javascript"});return URL.createObjectURL(l)}}return r}})},60413:(e,t,i)=>{"use strict";i.d(t,{Dy:()=>r,H8:()=>h,Qu:()=>m,Tc:()=>c,c8:()=>u,gm:()=>l,m0:()=>g,nr:()=>d,pR:()=>o});var s=i(25893);class n{constructor(){this.mapWindowIdToZoomFactor=new Map}static{this.INSTANCE=new n}getZoomFactor(e){return this.mapWindowIdToZoomFactor.get(this.getWindowId(e))??1}getWindowId(e){return e.vscodeWindowId}}function r(e,t,i){"string"===typeof t&&(t=e.matchMedia(t)),t.addEventListener("change",i)}function o(e){return n.INSTANCE.getZoomFactor(e)}const a=navigator.userAgent,l=a.indexOf("Firefox")>=0,c=a.indexOf("AppleWebKit")>=0,h=a.indexOf("Chrome")>=0,d=!h&&a.indexOf("Safari")>=0,u=!h&&!d&&c,g=(a.indexOf("Electron/"),a.indexOf("Android")>=0);let p=!1;if("function"===typeof s.G.matchMedia){const e=s.G.matchMedia("(display-mode: standalone) or (display-mode: window-controls-overlay)"),t=s.G.matchMedia("(display-mode: fullscreen)");p=e.matches,r(s.G,e,(({matches:e})=>{p&&t.matches||(p=e)}))}function m(){return p}},55089:(e,t,i)=>{"use strict";i.d(t,{e:()=>o});var s=i(60413),n=i(25893),r=i(98067);const o={clipboard:{writeText:r.ib||document.queryCommandSupported&&document.queryCommandSupported("copy")||!!(navigator&&navigator.clipboard&&navigator.clipboard.writeText),readText:r.ib||!!(navigator&&navigator.clipboard&&navigator.clipboard.readText)},keyboard:r.ib||s.Qu()?0:navigator.keyboard||s.nr?1:2,touch:"ontouchstart"in n.G||navigator.maxTouchPoints>0,pointerEvents:n.G.PointerEvent&&("ontouchstart"in n.G||navigator.maxTouchPoints>0)}},42731:(e,t,i)=>{"use strict";i.d(t,{t:()=>s});const s={RESOURCES:"ResourceURLs",DOWNLOAD_URL:"DownloadURL",FILES:"Files",TEXT:i(44320).K.text,INTERNAL_URI_LIST:"application/vnd.code.uri-list"}},8597:(e,t,i)=>{"use strict";i.d(t,{$:()=>Ue,BC:()=>Ie,BK:()=>j,Be:()=>F,Bx:()=>we,CE:()=>ze,Cl:()=>ee,Di:()=>Qe,Ej:()=>G,Er:()=>Se,Fv:()=>R,H4:()=>$,Hs:()=>Oe,Ij:()=>D,Iv:()=>w,L9:()=>H,Ln:()=>De,Mc:()=>et,OK:()=>Q,Oq:()=>M,PG:()=>P,Pl:()=>Ne,Q2:()=>E,QX:()=>X,TT:()=>$e,Tf:()=>je,Tr:()=>Y,U2:()=>_e,U3:()=>O,WU:()=>Be,Wt:()=>fe,X7:()=>se,XD:()=>Z,Xc:()=>I,ZF:()=>S,a:()=>re,a4:()=>qe,b2:()=>N,bo:()=>He,bq:()=>ie,cL:()=>z,fg:()=>V,fs:()=>Re,fz:()=>oe,gI:()=>Ye,h:()=>Je,i0:()=>Ge,jD:()=>We,jG:()=>te,jh:()=>le,ko:()=>k,kx:()=>ye,li:()=>he,mU:()=>K,nR:()=>ne,nY:()=>be,pN:()=>Xe,q3:()=>L,sb:()=>Ce,sd:()=>Le,tG:()=>B,vT:()=>Ve,w5:()=>Ae,w_:()=>T,wk:()=>xe,xZ:()=>Ee,y6:()=>q,yt:()=>Ke,zK:()=>Te,zk:()=>_});var s=i(60413),n=i(55089),r=i(72962),o=i(47358),a=i(90766),l=i(64383),c=i(41234),h=i(83750),d=i(5662),u=i(36456),g=i(98067),p=i(85600),m=i(25893);const{registerWindow:f,getWindow:_,getDocument:v,getWindows:C,getWindowsCount:b,getWindowId:E,getWindowById:S,hasWindow:y,onDidRegisterWindow:w,onWillUnregisterWindow:L,onDidUnregisterWindow:R}=function(){const e=new Map;(0,m.y)(m.G,1);const t={window:m.G,disposables:new d.Cm};e.set(m.G.vscodeWindowId,t);const i=new c.vl,s=new c.vl,n=new c.vl;return{onDidRegisterWindow:i.event,onWillUnregisterWindow:n.event,onDidUnregisterWindow:s.event,registerWindow(t){if(e.has(t.vscodeWindowId))return d.jG.None;const r=new d.Cm,o={window:t,disposables:r.add(new d.Cm)};return e.set(t.vscodeWindowId,o),r.add((0,d.s)((()=>{e.delete(t.vscodeWindowId),s.fire(t)}))),r.add(k(t,we.BEFORE_UNLOAD,(()=>{n.fire(t)}))),i.fire(o),r},getWindows:()=>e.values(),getWindowsCount:()=>e.size,getWindowId:e=>e.vscodeWindowId,hasWindow:t=>e.has(t),getWindowById:function(i,s){return("number"===typeof i?e.get(i):void 0)??(s?t:void 0)},getWindow(e){const t=e;if(t?.ownerDocument?.defaultView)return t.ownerDocument.defaultView.window;const i=e;return i?.view?i.view.window:m.G},getDocument:e=>_(e).document}}();function T(e){for(;e.firstChild;)e.firstChild.remove()}class x{constructor(e,t,i,s){this._node=e,this._type=t,this._handler=i,this._options=s||!1,this._node.addEventListener(this._type,this._handler,this._options)}dispose(){this._handler&&(this._node.removeEventListener(this._type,this._handler,this._options),this._node=null,this._handler=null)}}function k(e,t,i,s){return new x(e,t,i,s)}function A(e,t){return function(i){return t(new o.P(e,i))}}const N=function(e,t,i,s){let n=i;return"click"===t||"mousedown"===t||"contextmenu"===t?n=A(_(e),i):"keydown"!==t&&"keypress"!==t&&"keyup"!==t||(n=function(e){return function(t){return e(new r.Z(t))}}(i)),k(e,t,n,s)},I=function(e,t,i){return function(e,t,i){return k(e,g.un&&n.e.pointerEvents?we.POINTER_DOWN:we.MOUSE_DOWN,t,i)}(e,A(_(e),t),i)};function O(e,t,i){return(0,a.b7)(e,t,i)}class D extends a.A0{constructor(e,t){super(e,t)}}let M,P;class F extends a.vb{constructor(e){super(),this.defaultTarget=e&&_(e)}cancelAndSet(e,t,i){return super.cancelAndSet(e,t,i??this.defaultTarget)}}class U{constructor(e,t=0){this._runner=e,this.priority=t,this._canceled=!1}dispose(){this._canceled=!0}execute(){if(!this._canceled)try{this._runner()}catch(e){(0,l.dz)(e)}}static sort(e,t){return t.priority-e.priority}}function H(e){return _(e).getComputedStyle(e,null)}function B(e,t){const i=_(e),s=i.document;if(e!==s.body)return new V(e.clientWidth,e.clientHeight);if(g.un&&i?.visualViewport)return new V(i.visualViewport.width,i.visualViewport.height);if(i?.innerWidth&&i.innerHeight)return new V(i.innerWidth,i.innerHeight);if(s.body&&s.body.clientWidth&&s.body.clientHeight)return new V(s.body.clientWidth,s.body.clientHeight);if(s.documentElement&&s.documentElement.clientWidth&&s.documentElement.clientHeight)return new V(s.documentElement.clientWidth,s.documentElement.clientHeight);if(t)return B(t);throw new Error("Unable to figure out browser width and height")}!function(){const e=new Map,t=new Map,i=new Map,s=new Map;P=(n,r,o=0)=>{const a=E(n),l=new U(r,o);let c=e.get(a);return c||(c=[],e.set(a,c)),c.push(l),i.get(a)||(i.set(a,!0),n.requestAnimationFrame((()=>(n=>{i.set(n,!1);const r=e.get(n)??[];for(t.set(n,r),e.set(n,[]),s.set(n,!0);r.length>0;)r.sort(U.sort),r.shift().execute();s.set(n,!1)})(a)))),l},M=(e,i,n)=>{const r=E(e);if(s.get(r)){const e=new U(i,n);let s=t.get(r);return s||(s=[],t.set(r,s)),s.push(e),e}return P(e,i,n)}}();class W{static convertToPixels(e,t){return parseFloat(t)||0}static getDimension(e,t,i){const s=H(e),n=s?s.getPropertyValue(t):"0";return W.convertToPixels(e,n)}static getBorderLeftWidth(e){return W.getDimension(e,"border-left-width","borderLeftWidth")}static getBorderRightWidth(e){return W.getDimension(e,"border-right-width","borderRightWidth")}static getBorderTopWidth(e){return W.getDimension(e,"border-top-width","borderTopWidth")}static getBorderBottomWidth(e){return W.getDimension(e,"border-bottom-width","borderBottomWidth")}static getPaddingLeft(e){return W.getDimension(e,"padding-left","paddingLeft")}static getPaddingRight(e){return W.getDimension(e,"padding-right","paddingRight")}static getPaddingTop(e){return W.getDimension(e,"padding-top","paddingTop")}static getPaddingBottom(e){return W.getDimension(e,"padding-bottom","paddingBottom")}static getMarginLeft(e){return W.getDimension(e,"margin-left","marginLeft")}static getMarginTop(e){return W.getDimension(e,"margin-top","marginTop")}static getMarginRight(e){return W.getDimension(e,"margin-right","marginRight")}static getMarginBottom(e){return W.getDimension(e,"margin-bottom","marginBottom")}}class V{static{this.None=new V(0,0)}constructor(e,t){this.width=e,this.height=t}with(e=this.width,t=this.height){return e!==this.width||t!==this.height?new V(e,t):this}static is(e){return"object"===typeof e&&"number"===typeof e.height&&"number"===typeof e.width}static lift(e){return e instanceof V?e:new V(e.width,e.height)}static equals(e,t){return e===t||!(!e||!t)&&(e.width===t.width&&e.height===t.height)}}function z(e){let t=e.offsetParent,i=e.offsetTop,s=e.offsetLeft;for(;null!==(e=e.parentNode)&&e!==e.ownerDocument.body&&e!==e.ownerDocument.documentElement;){i-=e.scrollTop;const n=J(e)?null:H(e);n&&(s-="rtl"!==n.direction?e.scrollLeft:-e.scrollLeft),e===t&&(s+=W.getBorderLeftWidth(e),i+=W.getBorderTopWidth(e),i+=e.offsetTop,s+=e.offsetLeft,t=e.offsetParent)}return{left:s,top:i}}function G(e,t,i){"number"===typeof t&&(e.style.width=`${t}px`),"number"===typeof i&&(e.style.height=`${i}px`)}function j(e){const t=e.getBoundingClientRect(),i=_(e);return{left:t.left+i.scrollX,top:t.top+i.scrollY,width:t.width,height:t.height}}function K(e){let t=e,i=1;do{const e=H(t).zoom;null!==e&&void 0!==e&&"1"!==e&&(i*=e),t=t.parentElement}while(null!==t&&t!==t.ownerDocument.documentElement);return i}function Y(e){const t=W.getMarginLeft(e)+W.getMarginRight(e);return e.offsetWidth+t}function q(e){const t=W.getBorderLeftWidth(e)+W.getBorderRightWidth(e),i=W.getPaddingLeft(e)+W.getPaddingRight(e);return e.offsetWidth-t-i}function $(e){const t=W.getBorderTopWidth(e)+W.getBorderBottomWidth(e),i=W.getPaddingTop(e)+W.getPaddingBottom(e);return e.offsetHeight-t-i}function Q(e){const t=W.getMarginTop(e)+W.getMarginBottom(e);return e.offsetHeight+t}function X(e,t){return Boolean(t?.contains(e))}function Z(e,t,i){return!!function(e,t,i){for(;e&&e.nodeType===e.ELEMENT_NODE;){if(e.classList.contains(t))return e;if(i)if("string"===typeof i){if(e.classList.contains(i))return null}else if(e===i)return null;e=e.parentNode}return null}(e,t,i)}function J(e){return e&&!!e.host&&!!e.mode}function ee(e){return!!te(e)}function te(e){for(;e.parentNode;){if(e===e.ownerDocument?.body)return null;e=e.parentNode}return J(e)?e:null}function ie(){let e=re().activeElement;for(;e?.shadowRoot;)e=e.shadowRoot.activeElement;return e}function se(e){return ie()===e}function ne(e){return X(ie(),e)}function re(){if(b()<=1)return m.G.document;return Array.from(C()).map((({window:e})=>e.document)).find((e=>e.hasFocus()))??m.G.document}function oe(){const e=re();return e.defaultView?.window??m.G}const ae=new Map;function le(){return new ce}class ce{constructor(){this._currentCssStyle="",this._styleSheet=void 0}setStyle(e){e!==this._currentCssStyle&&(this._currentCssStyle=e,this._styleSheet?this._styleSheet.innerText=e:this._styleSheet=he(m.G.document.head,(t=>t.innerText=e)))}dispose(){this._styleSheet&&(this._styleSheet.remove(),this._styleSheet=void 0)}}function he(e=m.G.document.head,t,i){const s=document.createElement("style");if(s.type="text/css",s.media="screen",t?.(s),e.appendChild(s),i&&i.add((0,d.s)((()=>s.remove()))),e===m.G.document.head){const e=new Set;ae.set(s,e);for(const{window:t,disposables:n}of C()){if(t===m.G)continue;const r=n.add(de(s,e,t));i?.add(r)}}return s}function de(e,t,i){const s=new d.Cm,n=e.cloneNode(!0);i.document.head.appendChild(n),s.add((0,d.s)((()=>n.remove())));for(const r of me(e))n.sheet?.insertRule(r.cssText,n.sheet?.cssRules.length);return s.add(ue.observe(e,s,{childList:!0})((()=>{n.textContent=e.textContent}))),t.add(n),s.add((0,d.s)((()=>t.delete(n)))),s}const ue=new class{constructor(){this.mutationObservers=new Map}observe(e,t,i){let s=this.mutationObservers.get(e);s||(s=new Map,this.mutationObservers.set(e,s));const n=(0,p.tW)(i);let r=s.get(n);if(r)r.users+=1;else{const o=new c.vl,a=new MutationObserver((e=>o.fire(e)));a.observe(e,i);const l=r={users:1,observer:a,onDidMutate:o.event};t.add((0,d.s)((()=>{l.users-=1,0===l.users&&(o.dispose(),a.disconnect(),s?.delete(n),0===s?.size&&this.mutationObservers.delete(e))}))),s.set(n,r)}return r.onDidMutate}};let ge=null;function pe(){return ge||(ge=he()),ge}function me(e){return e?.sheet?.rules?e.sheet.rules:e?.sheet?.cssRules?e.sheet.cssRules:[]}function fe(e,t,i=pe()){if(i&&t){i.sheet?.insertRule(`${e} {${t}}`,0);for(const s of ae.get(i)??[])fe(e,t,s)}}function _e(e,t=pe()){if(!t)return;const i=me(t),s=[];for(let n=0;n=0;n--)t.sheet?.deleteRule(s[n]);for(const n of ae.get(t)??[])_e(e,n)}function ve(e){return"string"===typeof e.selectorText}function Ce(e){return e instanceof HTMLElement||e instanceof _(e).HTMLElement}function be(e){return e instanceof HTMLAnchorElement||e instanceof _(e).HTMLAnchorElement}function Ee(e){return e instanceof SVGElement||e instanceof _(e).SVGElement}function Se(e){return e instanceof MouseEvent||e instanceof _(e).MouseEvent}function ye(e){return e instanceof KeyboardEvent||e instanceof _(e).KeyboardEvent}const we={CLICK:"click",AUXCLICK:"auxclick",DBLCLICK:"dblclick",MOUSE_UP:"mouseup",MOUSE_DOWN:"mousedown",MOUSE_OVER:"mouseover",MOUSE_MOVE:"mousemove",MOUSE_OUT:"mouseout",MOUSE_ENTER:"mouseenter",MOUSE_LEAVE:"mouseleave",MOUSE_WHEEL:"wheel",POINTER_UP:"pointerup",POINTER_DOWN:"pointerdown",POINTER_MOVE:"pointermove",POINTER_LEAVE:"pointerleave",CONTEXT_MENU:"contextmenu",WHEEL:"wheel",KEY_DOWN:"keydown",KEY_PRESS:"keypress",KEY_UP:"keyup",LOAD:"load",BEFORE_UNLOAD:"beforeunload",UNLOAD:"unload",PAGE_SHOW:"pageshow",PAGE_HIDE:"pagehide",PASTE:"paste",ABORT:"abort",ERROR:"error",RESIZE:"resize",SCROLL:"scroll",FULLSCREEN_CHANGE:"fullscreenchange",WK_FULLSCREEN_CHANGE:"webkitfullscreenchange",SELECT:"select",CHANGE:"change",SUBMIT:"submit",RESET:"reset",FOCUS:"focus",FOCUS_IN:"focusin",FOCUS_OUT:"focusout",BLUR:"blur",INPUT:"input",STORAGE:"storage",DRAG_START:"dragstart",DRAG:"drag",DRAG_ENTER:"dragenter",DRAG_LEAVE:"dragleave",DRAG_OVER:"dragover",DROP:"drop",DRAG_END:"dragend",ANIMATION_START:s.Tc?"webkitAnimationStart":"animationstart",ANIMATION_END:s.Tc?"webkitAnimationEnd":"animationend",ANIMATION_ITERATION:s.Tc?"webkitAnimationIteration":"animationiteration"};function Le(e){const t=e;return!(!t||"function"!==typeof t.preventDefault||"function"!==typeof t.stopPropagation)}const Re={stop:(e,t)=>(e.preventDefault(),t&&e.stopPropagation(),e)};function Te(e){const t=[];for(let i=0;e&&e.nodeType===e.ELEMENT_NODE;i++)t[i]=e.scrollTop,e=e.parentNode;return t}function xe(e,t){for(let i=0;e&&e.nodeType===e.ELEMENT_NODE;i++)e.scrollTop!==t[i]&&(e.scrollTop=t[i]),e=e.parentNode}class ke extends d.jG{static hasFocusWithin(e){if(Ce(e)){const t=te(e);return X(t?t.activeElement:e.ownerDocument.activeElement,e)}{const t=e;return X(t.document.activeElement,t.document)}}constructor(e){super(),this._onDidFocus=this._register(new c.vl),this.onDidFocus=this._onDidFocus.event,this._onDidBlur=this._register(new c.vl),this.onDidBlur=this._onDidBlur.event;let t=ke.hasFocusWithin(e),i=!1;const s=()=>{i=!1,t||(t=!0,this._onDidFocus.fire())},n=()=>{t&&(i=!0,(Ce(e)?_(e):e).setTimeout((()=>{i&&(i=!1,t=!1,this._onDidBlur.fire())}),0))};this._refreshStateHandler=()=>{ke.hasFocusWithin(e)!==t&&(t?n():s())},this._register(k(e,we.FOCUS,s,!0)),this._register(k(e,we.BLUR,n,!0)),Ce(e)&&(this._register(k(e,we.FOCUS_IN,(()=>this._refreshStateHandler()))),this._register(k(e,we.FOCUS_OUT,(()=>this._refreshStateHandler()))))}}function Ae(e){return new ke(e)}function Ne(e,t){return e.after(t),t}function Ie(e,...t){if(e.append(...t),1===t.length&&"string"!==typeof t[0])return t[0]}function Oe(e,t){return e.insertBefore(t,e.firstChild),t}function De(e,...t){e.innerText="",Ie(e,...t)}const Me=/([\w\-]+)?(#([\w\-]+))?((\.([\w\-]+))*)/;var Pe;function Fe(e,t,i,...s){const n=Me.exec(t);if(!n)throw new Error("Bad use of emmet");const r=n[1]||"div";let o;return o=e!==Pe.HTML?document.createElementNS(e,r):document.createElement(r),n[3]&&(o.id=n[3]),n[4]&&(o.className=n[4].replace(/\./g," ").trim()),i&&Object.entries(i).forEach((([e,t])=>{"undefined"!==typeof t&&(/^on\w+$/.test(e)?o[e]=t:"selected"===e?t&&o.setAttribute(e,"true"):o.setAttribute(e,t))})),o.append(...s),o}function Ue(e,t,...i){return Fe(Pe.HTML,e,t,...i)}function He(e,...t){e?Be(...t):We(...t)}function Be(...e){for(const t of e)t.style.display="",t.removeAttribute("aria-hidden")}function We(...e){for(const t of e)t.style.display="none",t.setAttribute("aria-hidden","true")}function Ve(e,t){const i=e.devicePixelRatio*t;return Math.max(1,Math.floor(i))/e.devicePixelRatio}function ze(e){m.G.open(e,"_blank","noopener")}function Ge(e,t){const i=()=>{t(),s=P(e,i)};let s=P(e,i);return(0,d.s)((()=>s.dispose()))}function je(e){return e?`url('${u.zl.uriToBrowserUri(e).toString(!0).replace(/'/g,"%27")}')`:"url('')"}function Ke(e){return`'${e.replace(/'/g,"%27")}'`}function Ye(e,t){if(void 0!==e){const i=e.match(/^\s*var\((.+)\)$/);if(i){const e=i[1].split(",",2);return 2===e.length&&(t=Ye(e[1].trim(),t)),`var(${e[0]}, ${t})`}return e}return t}function qe(e,t=!1){const i=document.createElement("a");return h.$w("afterSanitizeAttributes",(s=>{for(const n of["href","src"])if(s.hasAttribute(n)){const r=s.getAttribute(n);if("href"===n&&r.startsWith("#"))continue;if(i.href=r,!e.includes(i.protocol.replace(/:$/,""))){if(t&&"src"===n&&i.href.startsWith("data:"))continue;s.removeAttribute(n)}}})),(0,d.s)((()=>{h.SV("afterSanitizeAttributes")}))}!function(e){e.HTML="http://www.w3.org/1999/xhtml",e.SVG="http://www.w3.org/2000/svg"}(Pe||(Pe={})),Ue.SVG=function(e,t,...i){return Fe(Pe.SVG,e,t,...i)},u.Ez.setPreferredWebSchema(/^https:/.test(m.G.location.href)?"https":"http");const $e=Object.freeze(["a","abbr","b","bdo","blockquote","br","caption","cite","code","col","colgroup","dd","del","details","dfn","div","dl","dt","em","figcaption","figure","h1","h2","h3","h4","h5","h6","hr","i","img","input","ins","kbd","label","li","mark","ol","p","pre","q","rp","rt","ruby","samp","small","small","source","span","strike","strong","sub","summary","sup","table","tbody","td","tfoot","th","thead","time","tr","tt","u","ul","var","video","wbr"]);Object.freeze({ALLOWED_TAGS:["a","button","blockquote","code","div","h1","h2","h3","h4","h5","h6","hr","input","label","li","p","pre","select","small","span","strong","textarea","ul","ol"],ALLOWED_ATTR:["href","data-href","data-command","target","title","name","src","alt","class","id","role","tabindex","style","data-code","width","height","align","x-dispatch","required","checked","placeholder","type","start"],RETURN_DOM:!1,RETURN_DOM_FRAGMENT:!1,RETURN_TRUSTED_TYPE:!0});class Qe extends c.vl{constructor(){super(),this._subscriptions=new d.Cm,this._keyStatus={altKey:!1,shiftKey:!1,ctrlKey:!1,metaKey:!1},this._subscriptions.add(c.Jh.runAndSubscribe(w,(({window:e,disposables:t})=>this.registerListeners(e,t)),{window:m.G,disposables:this._subscriptions}))}registerListeners(e,t){t.add(k(e,"keydown",(e=>{if(e.defaultPrevented)return;const t=new r.Z(e);if(6!==t.keyCode||!e.repeat){if(e.altKey&&!this._keyStatus.altKey)this._keyStatus.lastKeyPressed="alt";else if(e.ctrlKey&&!this._keyStatus.ctrlKey)this._keyStatus.lastKeyPressed="ctrl";else if(e.metaKey&&!this._keyStatus.metaKey)this._keyStatus.lastKeyPressed="meta";else if(e.shiftKey&&!this._keyStatus.shiftKey)this._keyStatus.lastKeyPressed="shift";else{if(6===t.keyCode)return;this._keyStatus.lastKeyPressed=void 0}this._keyStatus.altKey=e.altKey,this._keyStatus.ctrlKey=e.ctrlKey,this._keyStatus.metaKey=e.metaKey,this._keyStatus.shiftKey=e.shiftKey,this._keyStatus.lastKeyPressed&&(this._keyStatus.event=e,this.fire(this._keyStatus))}}),!0)),t.add(k(e,"keyup",(e=>{e.defaultPrevented||(!e.altKey&&this._keyStatus.altKey?this._keyStatus.lastKeyReleased="alt":!e.ctrlKey&&this._keyStatus.ctrlKey?this._keyStatus.lastKeyReleased="ctrl":!e.metaKey&&this._keyStatus.metaKey?this._keyStatus.lastKeyReleased="meta":!e.shiftKey&&this._keyStatus.shiftKey?this._keyStatus.lastKeyReleased="shift":this._keyStatus.lastKeyReleased=void 0,this._keyStatus.lastKeyPressed!==this._keyStatus.lastKeyReleased&&(this._keyStatus.lastKeyPressed=void 0),this._keyStatus.altKey=e.altKey,this._keyStatus.ctrlKey=e.ctrlKey,this._keyStatus.metaKey=e.metaKey,this._keyStatus.shiftKey=e.shiftKey,this._keyStatus.lastKeyReleased&&(this._keyStatus.event=e,this.fire(this._keyStatus)))}),!0)),t.add(k(e.document.body,"mousedown",(()=>{this._keyStatus.lastKeyPressed=void 0}),!0)),t.add(k(e.document.body,"mouseup",(()=>{this._keyStatus.lastKeyPressed=void 0}),!0)),t.add(k(e.document.body,"mousemove",(e=>{e.buttons&&(this._keyStatus.lastKeyPressed=void 0)}),!0)),t.add(k(e,"blur",(()=>{this.resetKeyStatus()})))}get keyStatus(){return this._keyStatus}resetKeyStatus(){this.doResetKeyStatus(),this.fire(this._keyStatus)}doResetKeyStatus(){this._keyStatus={altKey:!1,shiftKey:!1,ctrlKey:!1,metaKey:!1}}static getInstance(){return Qe.instance||(Qe.instance=new Qe),Qe.instance}dispose(){super.dispose(),this._subscriptions.dispose()}}class Xe extends d.jG{constructor(e,t){super(),this.element=e,this.callbacks=t,this.counter=0,this.dragStartTime=0,this.registerListeners()}registerListeners(){this.callbacks.onDragStart&&this._register(k(this.element,we.DRAG_START,(e=>{this.callbacks.onDragStart?.(e)}))),this.callbacks.onDrag&&this._register(k(this.element,we.DRAG,(e=>{this.callbacks.onDrag?.(e)}))),this._register(k(this.element,we.DRAG_ENTER,(e=>{this.counter++,this.dragStartTime=e.timeStamp,this.callbacks.onDragEnter?.(e)}))),this._register(k(this.element,we.DRAG_OVER,(e=>{e.preventDefault(),this.callbacks.onDragOver?.(e,e.timeStamp-this.dragStartTime)}))),this._register(k(this.element,we.DRAG_LEAVE,(e=>{this.counter--,0===this.counter&&(this.dragStartTime=0,this.callbacks.onDragLeave?.(e))}))),this._register(k(this.element,we.DRAG_END,(e=>{this.counter=0,this.dragStartTime=0,this.callbacks.onDragEnd?.(e)}))),this._register(k(this.element,we.DROP,(e=>{this.counter=0,this.dragStartTime=0,this.callbacks.onDrop?.(e)})))}}const Ze=/(?[\w\-]+)?(?:#(?[\w\-]+))?(?(?:\.(?:[\w\-]+))*)(?:@(?(?:[\w\_])+))?/;function Je(e,...t){let i,s;Array.isArray(t[0])?(i={},s=t[0]):(i=t[0]||{},s=t[1]);const n=Ze.exec(e);if(!n||!n.groups)throw new Error("Bad use of h");const r=n.groups.tag||"div",o=document.createElement(r);n.groups.id&&(o.id=n.groups.id);const a=[];if(n.groups.class)for(const c of n.groups.class.split("."))""!==c&&a.push(c);if(void 0!==i.className)for(const c of i.className.split("."))""!==c&&a.push(c);a.length>0&&(o.className=a.join(" "));const l={};if(n.groups.name&&(l[n.groups.name]=o),s)for(const c of s)Ce(c)?o.appendChild(c):"string"===typeof c?o.append(c):"root"in c&&(Object.assign(l,c),o.appendChild(c.root));for(const[c,h]of Object.entries(i))if("className"!==c)if("style"===c)for(const[e,t]of Object.entries(h))o.style.setProperty(tt(e),"number"===typeof t?t+"px":""+t);else"tabIndex"===c?o.tabIndex=h:o.setAttribute(tt(c),h.toString());return l.root=o,l}function et(e,...t){let i,s;Array.isArray(t[0])?(i={},s=t[0]):(i=t[0]||{},s=t[1]);const n=Ze.exec(e);if(!n||!n.groups)throw new Error("Bad use of h");const r=n.groups.tag||"div",o=document.createElementNS("http://www.w3.org/2000/svg",r);n.groups.id&&(o.id=n.groups.id);const a=[];if(n.groups.class)for(const c of n.groups.class.split("."))""!==c&&a.push(c);if(void 0!==i.className)for(const c of i.className.split("."))""!==c&&a.push(c);a.length>0&&(o.className=a.join(" "));const l={};if(n.groups.name&&(l[n.groups.name]=o),s)for(const c of s)Ce(c)?o.appendChild(c):"string"===typeof c?o.append(c):"root"in c&&(Object.assign(l,c),o.appendChild(c.root));for(const[c,h]of Object.entries(i))if("className"!==c)if("style"===c)for(const[e,t]of Object.entries(h))o.style.setProperty(tt(e),"number"===typeof t?t+"px":""+t);else"tabIndex"===c?o.tabIndex=h:o.setAttribute(tt(c),h.toString());return l.root=o,l}function tt(e){return e.replace(/([a-z])([A-Z])/g,"$1-$2").toLowerCase()}},83750:(e,t,i)=>{"use strict";i.d(t,{$w:()=>ae,SV:()=>le,aj:()=>oe});const{entries:s,setPrototypeOf:n,isFrozen:r,getPrototypeOf:o,getOwnPropertyDescriptor:a}=Object;let{freeze:l,seal:c,create:h}=Object,{apply:d,construct:u}="undefined"!==typeof Reflect&&Reflect;l||(l=function(e){return e}),c||(c=function(e){return e}),d||(d=function(e,t,i){return e.apply(t,i)}),u||(u=function(e,t){return new e(...t)});const g=R(Array.prototype.forEach),p=R(Array.prototype.pop),m=R(Array.prototype.push),f=R(String.prototype.toLowerCase),_=R(String.prototype.toString),v=R(String.prototype.match),C=R(String.prototype.replace),b=R(String.prototype.indexOf),E=R(String.prototype.trim),S=R(Object.prototype.hasOwnProperty),y=R(RegExp.prototype.test),w=(L=TypeError,function(){for(var e=arguments.length,t=new Array(e),i=0;i1?i-1:0),n=1;n2&&void 0!==arguments[2]?arguments[2]:f;n&&n(e,null);let s=t.length;for(;s--;){let n=t[s];if("string"===typeof n){const e=i(n);e!==n&&(r(t)||(t[s]=e),n=e)}e[n]=!0}return e}function x(e){for(let t=0;t/gm),G=c(/\${[\w\W]*}/gm),j=c(/^data-[\-\w.\u00B7-\uFFFF]/),K=c(/^aria-[\-\w]+$/),Y=c(/^(?:(?:(?:f|ht)tps?|mailto|tel|callto|sms|cid|xmpp):|[^a-z]|[a-z+.\-]+(?:[^a-z+.\-:]|$))/i),q=c(/^(?:\w+script|data):/i),$=c(/[\u0000-\u0020\u00A0\u1680\u180E\u2000-\u2029\u205F\u3000]/g),Q=c(/^html$/i),X=c(/^[a-z][.\w]*(-[.\w]+)+$/i);var Z=Object.freeze({__proto__:null,MUSTACHE_EXPR:V,ERB_EXPR:z,TMPLIT_EXPR:G,DATA_ATTR:j,ARIA_ATTR:K,IS_ALLOWED_URI:Y,IS_SCRIPT_OR_DATA:q,ATTR_WHITESPACE:$,DOCTYPE_NAME:Q,CUSTOM_ELEMENT:X});const J=1,ee=3,te=7,ie=8,se=9,ne=function(){return"undefined"===typeof window?null:window};var re=function e(){let t=arguments.length>0&&void 0!==arguments[0]?arguments[0]:ne();const i=t=>e(t);if(i.version="3.1.7",i.removed=[],!t||!t.document||t.document.nodeType!==se)return i.isSupported=!1,i;let{document:n}=t;const r=n,o=r.currentScript,{DocumentFragment:a,HTMLTemplateElement:c,Node:d,Element:u,NodeFilter:L,NamedNodeMap:R=t.NamedNodeMap||t.MozNamedAttrMap,HTMLFormElement:x,DOMParser:V,trustedTypes:z}=t,G=u.prototype,j=A(G,"cloneNode"),K=A(G,"remove"),q=A(G,"nextSibling"),$=A(G,"childNodes"),X=A(G,"parentNode");if("function"===typeof c){const e=n.createElement("template");e.content&&e.content.ownerDocument&&(n=e.content.ownerDocument)}let re,oe="";const{implementation:ae,createNodeIterator:le,createDocumentFragment:ce,getElementsByTagName:he}=n,{importNode:de}=r;let ue={};i.isSupported="function"===typeof s&&"function"===typeof X&&ae&&void 0!==ae.createHTMLDocument;const{MUSTACHE_EXPR:ge,ERB_EXPR:pe,TMPLIT_EXPR:me,DATA_ATTR:fe,ARIA_ATTR:_e,IS_SCRIPT_OR_DATA:ve,ATTR_WHITESPACE:Ce,CUSTOM_ELEMENT:be}=Z;let{IS_ALLOWED_URI:Ee}=Z,Se=null;const ye=T({},[...N,...I,...O,...M,...F]);let we=null;const Le=T({},[...U,...H,...B,...W]);let Re=Object.seal(h(null,{tagNameCheck:{writable:!0,configurable:!1,enumerable:!0,value:null},attributeNameCheck:{writable:!0,configurable:!1,enumerable:!0,value:null},allowCustomizedBuiltInElements:{writable:!0,configurable:!1,enumerable:!0,value:!1}})),Te=null,xe=null,ke=!0,Ae=!0,Ne=!1,Ie=!0,Oe=!1,De=!0,Me=!1,Pe=!1,Fe=!1,Ue=!1,He=!1,Be=!1,We=!0,Ve=!1,ze=!0,Ge=!1,je={},Ke=null;const Ye=T({},["annotation-xml","audio","colgroup","desc","foreignobject","head","iframe","math","mi","mn","mo","ms","mtext","noembed","noframes","noscript","plaintext","script","style","svg","template","thead","title","video","xmp"]);let qe=null;const $e=T({},["audio","video","img","source","image","track"]);let Qe=null;const Xe=T({},["alt","class","for","id","label","name","pattern","placeholder","role","summary","title","value","style","xmlns"]),Ze="http://www.w3.org/1998/Math/MathML",Je="http://www.w3.org/2000/svg",et="http://www.w3.org/1999/xhtml";let tt=et,it=!1,st=null;const nt=T({},[Ze,Je,et],_);let rt=null;const ot=["application/xhtml+xml","text/html"];let at=null,lt=null;const ct=n.createElement("form"),ht=function(e){return e instanceof RegExp||e instanceof Function},dt=function(){let e=arguments.length>0&&void 0!==arguments[0]?arguments[0]:{};if(!lt||lt!==e){if(e&&"object"===typeof e||(e={}),e=k(e),rt=-1===ot.indexOf(e.PARSER_MEDIA_TYPE)?"text/html":e.PARSER_MEDIA_TYPE,at="application/xhtml+xml"===rt?_:f,Se=S(e,"ALLOWED_TAGS")?T({},e.ALLOWED_TAGS,at):ye,we=S(e,"ALLOWED_ATTR")?T({},e.ALLOWED_ATTR,at):Le,st=S(e,"ALLOWED_NAMESPACES")?T({},e.ALLOWED_NAMESPACES,_):nt,Qe=S(e,"ADD_URI_SAFE_ATTR")?T(k(Xe),e.ADD_URI_SAFE_ATTR,at):Xe,qe=S(e,"ADD_DATA_URI_TAGS")?T(k($e),e.ADD_DATA_URI_TAGS,at):$e,Ke=S(e,"FORBID_CONTENTS")?T({},e.FORBID_CONTENTS,at):Ye,Te=S(e,"FORBID_TAGS")?T({},e.FORBID_TAGS,at):{},xe=S(e,"FORBID_ATTR")?T({},e.FORBID_ATTR,at):{},je=!!S(e,"USE_PROFILES")&&e.USE_PROFILES,ke=!1!==e.ALLOW_ARIA_ATTR,Ae=!1!==e.ALLOW_DATA_ATTR,Ne=e.ALLOW_UNKNOWN_PROTOCOLS||!1,Ie=!1!==e.ALLOW_SELF_CLOSE_IN_ATTR,Oe=e.SAFE_FOR_TEMPLATES||!1,De=!1!==e.SAFE_FOR_XML,Me=e.WHOLE_DOCUMENT||!1,Ue=e.RETURN_DOM||!1,He=e.RETURN_DOM_FRAGMENT||!1,Be=e.RETURN_TRUSTED_TYPE||!1,Fe=e.FORCE_BODY||!1,We=!1!==e.SANITIZE_DOM,Ve=e.SANITIZE_NAMED_PROPS||!1,ze=!1!==e.KEEP_CONTENT,Ge=e.IN_PLACE||!1,Ee=e.ALLOWED_URI_REGEXP||Y,tt=e.NAMESPACE||et,Re=e.CUSTOM_ELEMENT_HANDLING||{},e.CUSTOM_ELEMENT_HANDLING&&ht(e.CUSTOM_ELEMENT_HANDLING.tagNameCheck)&&(Re.tagNameCheck=e.CUSTOM_ELEMENT_HANDLING.tagNameCheck),e.CUSTOM_ELEMENT_HANDLING&&ht(e.CUSTOM_ELEMENT_HANDLING.attributeNameCheck)&&(Re.attributeNameCheck=e.CUSTOM_ELEMENT_HANDLING.attributeNameCheck),e.CUSTOM_ELEMENT_HANDLING&&"boolean"===typeof e.CUSTOM_ELEMENT_HANDLING.allowCustomizedBuiltInElements&&(Re.allowCustomizedBuiltInElements=e.CUSTOM_ELEMENT_HANDLING.allowCustomizedBuiltInElements),Oe&&(Ae=!1),He&&(Ue=!0),je&&(Se=T({},F),we=[],!0===je.html&&(T(Se,N),T(we,U)),!0===je.svg&&(T(Se,I),T(we,H),T(we,W)),!0===je.svgFilters&&(T(Se,O),T(we,H),T(we,W)),!0===je.mathMl&&(T(Se,M),T(we,B),T(we,W))),e.ADD_TAGS&&(Se===ye&&(Se=k(Se)),T(Se,e.ADD_TAGS,at)),e.ADD_ATTR&&(we===Le&&(we=k(we)),T(we,e.ADD_ATTR,at)),e.ADD_URI_SAFE_ATTR&&T(Qe,e.ADD_URI_SAFE_ATTR,at),e.FORBID_CONTENTS&&(Ke===Ye&&(Ke=k(Ke)),T(Ke,e.FORBID_CONTENTS,at)),ze&&(Se["#text"]=!0),Me&&T(Se,["html","head","body"]),Se.table&&(T(Se,["tbody"]),delete Te.tbody),e.TRUSTED_TYPES_POLICY){if("function"!==typeof e.TRUSTED_TYPES_POLICY.createHTML)throw w('TRUSTED_TYPES_POLICY configuration option must provide a "createHTML" hook.');if("function"!==typeof e.TRUSTED_TYPES_POLICY.createScriptURL)throw w('TRUSTED_TYPES_POLICY configuration option must provide a "createScriptURL" hook.');re=e.TRUSTED_TYPES_POLICY,oe=re.createHTML("")}else void 0===re&&(re=function(e,t){if("object"!==typeof e||"function"!==typeof e.createPolicy)return null;let i=null;const s="data-tt-policy-suffix";t&&t.hasAttribute(s)&&(i=t.getAttribute(s));const n="dompurify"+(i?"#"+i:"");try{return e.createPolicy(n,{createHTML:e=>e,createScriptURL:e=>e})}catch(r){return console.warn("TrustedTypes policy "+n+" could not be created."),null}}(z,o)),null!==re&&"string"===typeof oe&&(oe=re.createHTML(""));l&&l(e),lt=e}},ut=T({},["mi","mo","mn","ms","mtext"]),gt=T({},["annotation-xml"]),pt=T({},["title","style","font","a","script"]),mt=T({},[...I,...O,...D]),ft=T({},[...M,...P]),_t=function(e){m(i.removed,{element:e});try{X(e).removeChild(e)}catch(t){K(e)}},vt=function(e,t){try{m(i.removed,{attribute:t.getAttributeNode(e),from:t})}catch(s){m(i.removed,{attribute:null,from:t})}if(t.removeAttribute(e),"is"===e&&!we[e])if(Ue||He)try{_t(t)}catch(s){}else try{t.setAttribute(e,"")}catch(s){}},Ct=function(e){let t=null,i=null;if(Fe)e=""+e;else{const t=v(e,/^[\r\n\t ]+/);i=t&&t[0]}"application/xhtml+xml"===rt&&tt===et&&(e=''+e+"");const s=re?re.createHTML(e):e;if(tt===et)try{t=(new V).parseFromString(s,rt)}catch(o){}if(!t||!t.documentElement){t=ae.createDocument(tt,"template",null);try{t.documentElement.innerHTML=it?oe:s}catch(o){}}const r=t.body||t.documentElement;return e&&i&&r.insertBefore(n.createTextNode(i),r.childNodes[0]||null),tt===et?he.call(t,Me?"html":"body")[0]:Me?t.documentElement:r},bt=function(e){return le.call(e.ownerDocument||e,e,L.SHOW_ELEMENT|L.SHOW_COMMENT|L.SHOW_TEXT|L.SHOW_PROCESSING_INSTRUCTION|L.SHOW_CDATA_SECTION,null)},Et=function(e){return e instanceof x&&("string"!==typeof e.nodeName||"string"!==typeof e.textContent||"function"!==typeof e.removeChild||!(e.attributes instanceof R)||"function"!==typeof e.removeAttribute||"function"!==typeof e.setAttribute||"string"!==typeof e.namespaceURI||"function"!==typeof e.insertBefore||"function"!==typeof e.hasChildNodes)},St=function(e){return"function"===typeof d&&e instanceof d},yt=function(e,t,s){ue[e]&&g(ue[e],(e=>{e.call(i,t,s,lt)}))},wt=function(e){let t=null;if(yt("beforeSanitizeElements",e,null),Et(e))return _t(e),!0;const s=at(e.nodeName);if(yt("uponSanitizeElement",e,{tagName:s,allowedTags:Se}),e.hasChildNodes()&&!St(e.firstElementChild)&&y(/<[/\w]/g,e.innerHTML)&&y(/<[/\w]/g,e.textContent))return _t(e),!0;if(e.nodeType===te)return _t(e),!0;if(De&&e.nodeType===ie&&y(/<[/\w]/g,e.data))return _t(e),!0;if(!Se[s]||Te[s]){if(!Te[s]&&Rt(s)){if(Re.tagNameCheck instanceof RegExp&&y(Re.tagNameCheck,s))return!1;if(Re.tagNameCheck instanceof Function&&Re.tagNameCheck(s))return!1}if(ze&&!Ke[s]){const t=X(e)||e.parentNode,i=$(e)||e.childNodes;if(i&&t){for(let s=i.length-1;s>=0;--s){const n=j(i[s],!0);n.__removalCount=(e.__removalCount||0)+1,t.insertBefore(n,q(e))}}}return _t(e),!0}return e instanceof u&&!function(e){let t=X(e);t&&t.tagName||(t={namespaceURI:tt,tagName:"template"});const i=f(e.tagName),s=f(t.tagName);return!!st[e.namespaceURI]&&(e.namespaceURI===Je?t.namespaceURI===et?"svg"===i:t.namespaceURI===Ze?"svg"===i&&("annotation-xml"===s||ut[s]):Boolean(mt[i]):e.namespaceURI===Ze?t.namespaceURI===et?"math"===i:t.namespaceURI===Je?"math"===i&>[s]:Boolean(ft[i]):e.namespaceURI===et?!(t.namespaceURI===Je&&!gt[s])&&!(t.namespaceURI===Ze&&!ut[s])&&!ft[i]&&(pt[i]||!mt[i]):!("application/xhtml+xml"!==rt||!st[e.namespaceURI]))}(e)?(_t(e),!0):"noscript"!==s&&"noembed"!==s&&"noframes"!==s||!y(/<\/no(script|embed|frames)/i,e.innerHTML)?(Oe&&e.nodeType===ee&&(t=e.textContent,g([ge,pe,me],(e=>{t=C(t,e," ")})),e.textContent!==t&&(m(i.removed,{element:e.cloneNode()}),e.textContent=t)),yt("afterSanitizeElements",e,null),!1):(_t(e),!0)},Lt=function(e,t,i){if(We&&("id"===t||"name"===t)&&(i in n||i in ct))return!1;if(Ae&&!xe[t]&&y(fe,t));else if(ke&&y(_e,t));else if(!we[t]||xe[t]){if(!(Rt(e)&&(Re.tagNameCheck instanceof RegExp&&y(Re.tagNameCheck,e)||Re.tagNameCheck instanceof Function&&Re.tagNameCheck(e))&&(Re.attributeNameCheck instanceof RegExp&&y(Re.attributeNameCheck,t)||Re.attributeNameCheck instanceof Function&&Re.attributeNameCheck(t))||"is"===t&&Re.allowCustomizedBuiltInElements&&(Re.tagNameCheck instanceof RegExp&&y(Re.tagNameCheck,i)||Re.tagNameCheck instanceof Function&&Re.tagNameCheck(i))))return!1}else if(Qe[t]);else if(y(Ee,C(i,Ce,"")));else if("src"!==t&&"xlink:href"!==t&&"href"!==t||"script"===e||0!==b(i,"data:")||!qe[e]){if(Ne&&!y(ve,C(i,Ce,"")));else if(i)return!1}else;return!0},Rt=function(e){return"annotation-xml"!==e&&v(e,be)},Tt=function(e){yt("beforeSanitizeAttributes",e,null);const{attributes:t}=e;if(!t)return;const s={attrName:"",attrValue:"",keepAttr:!0,allowedAttributes:we};let n=t.length;for(;n--;){const o=t[n],{name:a,namespaceURI:l,value:c}=o,h=at(a);let d="value"===a?c:E(c);if(s.attrName=h,s.attrValue=d,s.keepAttr=!0,s.forceKeepAttr=void 0,yt("uponSanitizeAttribute",e,s),d=s.attrValue,s.forceKeepAttr)continue;if(vt(a,e),!s.keepAttr)continue;if(!Ie&&y(/\/>/i,d)){vt(a,e);continue}Oe&&g([ge,pe,me],(e=>{d=C(d,e," ")}));const u=at(e.nodeName);if(Lt(u,h,d))if(!Ve||"id"!==h&&"name"!==h||(vt(a,e),d="user-content-"+d),De&&y(/((--!?|])>)|<\/(style|title)/i,d))vt(a,e);else{if(re&&"object"===typeof z&&"function"===typeof z.getAttributeType)if(l);else switch(z.getAttributeType(u,h)){case"TrustedHTML":d=re.createHTML(d);break;case"TrustedScriptURL":d=re.createScriptURL(d)}try{l?e.setAttributeNS(l,a,d):e.setAttribute(a,d),Et(e)?_t(e):p(i.removed)}catch(r){}}}yt("afterSanitizeAttributes",e,null)},xt=function e(t){let i=null;const s=bt(t);for(yt("beforeSanitizeShadowDOM",t,null);i=s.nextNode();)yt("uponSanitizeShadowNode",i,null),wt(i)||(i.content instanceof a&&e(i.content),Tt(i));yt("afterSanitizeShadowDOM",t,null)};return i.sanitize=function(e){let t=arguments.length>1&&void 0!==arguments[1]?arguments[1]:{},s=null,n=null,o=null,l=null;if(it=!e,it&&(e="\x3c!--\x3e"),"string"!==typeof e&&!St(e)){if("function"!==typeof e.toString)throw w("toString is not a function");if("string"!==typeof(e=e.toString()))throw w("dirty is not a string, aborting")}if(!i.isSupported)return e;if(Pe||dt(t),i.removed=[],"string"===typeof e&&(Ge=!1),Ge){if(e.nodeName){const t=at(e.nodeName);if(!Se[t]||Te[t])throw w("root node is forbidden and cannot be sanitized in-place")}}else if(e instanceof d)s=Ct("\x3c!----\x3e"),n=s.ownerDocument.importNode(e,!0),n.nodeType===J&&"BODY"===n.nodeName||"HTML"===n.nodeName?s=n:s.appendChild(n);else{if(!Ue&&!Oe&&!Me&&-1===e.indexOf("<"))return re&&Be?re.createHTML(e):e;if(s=Ct(e),!s)return Ue?null:Be?oe:""}s&&Fe&&_t(s.firstChild);const c=bt(Ge?e:s);for(;o=c.nextNode();)wt(o)||(o.content instanceof a&&xt(o.content),Tt(o));if(Ge)return e;if(Ue){if(He)for(l=ce.call(s.ownerDocument);s.firstChild;)l.appendChild(s.firstChild);else l=s;return(we.shadowroot||we.shadowrootmode)&&(l=de.call(r,l,!0)),l}let h=Me?s.outerHTML:s.innerHTML;return Me&&Se["!doctype"]&&s.ownerDocument&&s.ownerDocument.doctype&&s.ownerDocument.doctype.name&&y(Q,s.ownerDocument.doctype.name)&&(h="\n"+h),Oe&&g([ge,pe,me],(e=>{h=C(h,e," ")})),re&&Be?re.createHTML(h):h},i.setConfig=function(){dt(arguments.length>0&&void 0!==arguments[0]?arguments[0]:{}),Pe=!0},i.clearConfig=function(){lt=null,Pe=!1},i.isValidAttribute=function(e,t,i){lt||dt({});const s=at(e),n=at(t);return Lt(s,n,i)},i.addHook=function(e,t){"function"===typeof t&&(ue[e]=ue[e]||[],m(ue[e],t))},i.removeHook=function(e){if(ue[e])return p(ue[e])},i.removeHooks=function(e){ue[e]&&(ue[e]=[])},i.removeAllHooks=function(){ue={}},i}();re.version,re.isSupported;const oe=re.sanitize,ae=(re.setConfig,re.clearConfig,re.isValidAttribute,re.addHook),le=re.removeHook;re.removeHooks,re.removeAllHooks},56245:(e,t,i)=>{"use strict";i.d(t,{f:()=>n});var s=i(41234);class n{get event(){return this.emitter.event}constructor(e,t,i){const n=e=>this.emitter.fire(e);this.emitter=new s.vl({onWillAddFirstListener:()=>e.addEventListener(t,n,i),onDidRemoveLastListener:()=>e.removeEventListener(t,n,i)})}dispose(){this.emitter.dispose()}}},55275:(e,t,i)=>{"use strict";i.d(t,{D:()=>s,Z:()=>r});class s{constructor(e){this.domNode=e,this._maxWidth="",this._width="",this._height="",this._top="",this._left="",this._bottom="",this._right="",this._paddingLeft="",this._fontFamily="",this._fontWeight="",this._fontSize="",this._fontStyle="",this._fontFeatureSettings="",this._fontVariationSettings="",this._textDecoration="",this._lineHeight="",this._letterSpacing="",this._className="",this._display="",this._position="",this._visibility="",this._color="",this._backgroundColor="",this._layerHint=!1,this._contain="none",this._boxShadow=""}setMaxWidth(e){const t=n(e);this._maxWidth!==t&&(this._maxWidth=t,this.domNode.style.maxWidth=this._maxWidth)}setWidth(e){const t=n(e);this._width!==t&&(this._width=t,this.domNode.style.width=this._width)}setHeight(e){const t=n(e);this._height!==t&&(this._height=t,this.domNode.style.height=this._height)}setTop(e){const t=n(e);this._top!==t&&(this._top=t,this.domNode.style.top=this._top)}setLeft(e){const t=n(e);this._left!==t&&(this._left=t,this.domNode.style.left=this._left)}setBottom(e){const t=n(e);this._bottom!==t&&(this._bottom=t,this.domNode.style.bottom=this._bottom)}setRight(e){const t=n(e);this._right!==t&&(this._right=t,this.domNode.style.right=this._right)}setPaddingLeft(e){const t=n(e);this._paddingLeft!==t&&(this._paddingLeft=t,this.domNode.style.paddingLeft=this._paddingLeft)}setFontFamily(e){this._fontFamily!==e&&(this._fontFamily=e,this.domNode.style.fontFamily=this._fontFamily)}setFontWeight(e){this._fontWeight!==e&&(this._fontWeight=e,this.domNode.style.fontWeight=this._fontWeight)}setFontSize(e){const t=n(e);this._fontSize!==t&&(this._fontSize=t,this.domNode.style.fontSize=this._fontSize)}setFontStyle(e){this._fontStyle!==e&&(this._fontStyle=e,this.domNode.style.fontStyle=this._fontStyle)}setFontFeatureSettings(e){this._fontFeatureSettings!==e&&(this._fontFeatureSettings=e,this.domNode.style.fontFeatureSettings=this._fontFeatureSettings)}setFontVariationSettings(e){this._fontVariationSettings!==e&&(this._fontVariationSettings=e,this.domNode.style.fontVariationSettings=this._fontVariationSettings)}setTextDecoration(e){this._textDecoration!==e&&(this._textDecoration=e,this.domNode.style.textDecoration=this._textDecoration)}setLineHeight(e){const t=n(e);this._lineHeight!==t&&(this._lineHeight=t,this.domNode.style.lineHeight=this._lineHeight)}setLetterSpacing(e){const t=n(e);this._letterSpacing!==t&&(this._letterSpacing=t,this.domNode.style.letterSpacing=this._letterSpacing)}setClassName(e){this._className!==e&&(this._className=e,this.domNode.className=this._className)}toggleClassName(e,t){this.domNode.classList.toggle(e,t),this._className=this.domNode.className}setDisplay(e){this._display!==e&&(this._display=e,this.domNode.style.display=this._display)}setPosition(e){this._position!==e&&(this._position=e,this.domNode.style.position=this._position)}setVisibility(e){this._visibility!==e&&(this._visibility=e,this.domNode.style.visibility=this._visibility)}setColor(e){this._color!==e&&(this._color=e,this.domNode.style.color=this._color)}setBackgroundColor(e){this._backgroundColor!==e&&(this._backgroundColor=e,this.domNode.style.backgroundColor=this._backgroundColor)}setLayerHinting(e){this._layerHint!==e&&(this._layerHint=e,this.domNode.style.transform=this._layerHint?"translate3d(0px, 0px, 0px)":"")}setBoxShadow(e){this._boxShadow!==e&&(this._boxShadow=e,this.domNode.style.boxShadow=e)}setContain(e){this._contain!==e&&(this._contain=e,this.domNode.style.contain=this._contain)}setAttribute(e,t){this.domNode.setAttribute(e,t)}removeAttribute(e){this.domNode.removeAttribute(e)}appendChild(e){this.domNode.appendChild(e.domNode)}removeChild(e){this.domNode.removeChild(e.domNode)}}function n(e){return"number"===typeof e?`${e}px`:e}function r(e){return new s(e)}},49435:(e,t,i)=>{"use strict";i.d(t,{z:()=>n});var s=i(98067);const n=s.uF?'"Segoe WPC", "Segoe UI", sans-serif':s.zx?"-apple-system, BlinkMacSystemFont, sans-serif":'system-ui, "Ubuntu", "Droid Sans", sans-serif'},27661:(e,t,i)=>{"use strict";i.d(t,{S5:()=>n,n:()=>o,yk:()=>r});var s=i(8597);function n(e,t={}){const i=o(t);return i.textContent=e,i}function r(e,t={}){const i=o(t);return l(i,function(e,t){const i={type:1,children:[]};let s=0,n=i;const r=[],o=new a(e);for(;!o.eos();){let e=o.next();const i="\\"===e&&0!==h(o.peek(),t);if(i&&(e=o.next()),!i&&c(e,t)&&e===o.peek()){o.advance(),2===n.type&&(n=r.pop());const i=h(e,t);if(n.type===i||5===n.type&&6===i)n=r.pop();else{const e={type:i,children:[]};5===i&&(e.index=s,s++),n.children.push(e),r.push(n),n=e}}else if("\n"===e)2===n.type&&(n=r.pop()),n.children.push({type:8});else if(2!==n.type){const t={type:2,content:e};n.children.push(t),r.push(n),n=t}else n.content+=e}2===n.type&&(n=r.pop());r.length;return i}(e,!!t.renderCodeSegments),t.actionHandler,t.renderCodeSegments),i}function o(e){const t=e.inline?"span":"div",i=document.createElement(t);return e.className&&(i.className=e.className),i}class a{constructor(e){this.source=e,this.index=0}eos(){return this.index>=this.source.length}next(){const e=this.peek();return this.advance(),e}peek(){return this.source[this.index]}advance(){this.index++}}function l(e,t,i,n){let r;if(2===t.type)r=document.createTextNode(t.content||"");else if(3===t.type)r=document.createElement("b");else if(4===t.type)r=document.createElement("i");else if(7===t.type&&n)r=document.createElement("code");else if(5===t.type&&i){const e=document.createElement("a");i.disposables.add(s.b2(e,"click",(e=>{i.callback(String(t.index),e)}))),r=e}else 8===t.type?r=document.createElement("br"):1===t.type&&(r=e);r&&e!==r&&e.appendChild(r),r&&Array.isArray(t.children)&&t.children.forEach((e=>{l(r,e,i,n)}))}function c(e,t){return 0!==h(e,t)}function h(e,t){switch(e){case"*":return 3;case"_":return 4;case"[":return 5;case"]":return 6;case"`":return t?7:0;default:return 0}}},34072:(e,t,i)=>{"use strict";i.d(t,{_:()=>r});var s=i(8597),n=i(5662);class r{constructor(){this._hooks=new n.Cm,this._pointerMoveCallback=null,this._onStopCallback=null}dispose(){this.stopMonitoring(!1),this._hooks.dispose()}stopMonitoring(e,t){if(!this.isMonitoring())return;this._hooks.clear(),this._pointerMoveCallback=null;const i=this._onStopCallback;this._onStopCallback=null,e&&i&&i(t)}isMonitoring(){return!!this._pointerMoveCallback}startMonitoring(e,t,i,r,o){this.isMonitoring()&&this.stopMonitoring(!1),this._pointerMoveCallback=r,this._onStopCallback=o;let a=e;try{e.setPointerCapture(t),this._hooks.add((0,n.s)((()=>{try{e.releasePointerCapture(t)}catch(i){}})))}catch(l){a=s.zk(e)}this._hooks.add(s.ko(a,s.Bx.POINTER_MOVE,(e=>{e.buttons===i?(e.preventDefault(),this._pointerMoveCallback(e)):this.stopMonitoring(!0)}))),this._hooks.add(s.ko(a,s.Bx.POINTER_UP,(e=>this.stopMonitoring(!0))))}}},72962:(e,t,i)=>{"use strict";i.d(t,{Z:()=>c});var s=i(60413),n=i(24939),r=i(42539),o=i(98067);const a=o.zx?256:2048,l=o.zx?2048:256;class c{constructor(e){this._standardKeyboardEventBrand=!0;const t=e;this.browserEvent=t,this.target=t.target,this.ctrlKey=t.ctrlKey,this.shiftKey=t.shiftKey,this.altKey=t.altKey,this.metaKey=t.metaKey,this.altGraphKey=t.getModifierState?.("AltGraph"),this.keyCode=function(e){if(e.charCode){const t=String.fromCharCode(e.charCode).toUpperCase();return n.YM.fromString(t)}const t=e.keyCode;if(3===t)return 7;if(s.gm)switch(t){case 59:return 85;case 60:if(o.j9)return 97;break;case 61:return 86;case 107:return 109;case 109:return 111;case 173:return 88;case 224:if(o.zx)return 57}else if(s.Tc){if(o.zx&&93===t)return 57;if(!o.zx&&92===t)return 57}return n.uw[t]||0}(t),this.code=t.code,this.ctrlKey=this.ctrlKey||5===this.keyCode,this.altKey=this.altKey||6===this.keyCode,this.shiftKey=this.shiftKey||4===this.keyCode,this.metaKey=this.metaKey||57===this.keyCode,this._asKeybinding=this._computeKeybinding(),this._asKeyCodeChord=this._computeKeyCodeChord()}preventDefault(){this.browserEvent&&this.browserEvent.preventDefault&&this.browserEvent.preventDefault()}stopPropagation(){this.browserEvent&&this.browserEvent.stopPropagation&&this.browserEvent.stopPropagation()}toKeyCodeChord(){return this._asKeyCodeChord}equals(e){return this._asKeybinding===e}_computeKeybinding(){let e=0;5!==this.keyCode&&4!==this.keyCode&&6!==this.keyCode&&57!==this.keyCode&&(e=this.keyCode);let t=0;return this.ctrlKey&&(t|=a),this.altKey&&(t|=512),this.shiftKey&&(t|=1024),this.metaKey&&(t|=l),t|=e,t}_computeKeyCodeChord(){let e=0;return 5!==this.keyCode&&4!==this.keyCode&&6!==this.keyCode&&57!==this.keyCode&&(e=this.keyCode),new r.dG(this.ctrlKey,this.shiftKey,this.altKey,this.metaKey,e)}}},68214:(e,t,i)=>{"use strict";i.d(t,{Gc:()=>A,R9:()=>P});var s=i(8597),n=i(83750),r=i(56245),o=i(27661),a=i(72962),l=i(47358),c=i(20370),h=i(64383),d=i(41234),u=i(16980),g=i(37882),p=i(96032),m=i(91090),f=i(5662);let _={};!function(){function e(e,t){t(_)}var t,i;e.amd=!0,t=this,i=function(e){function t(){return{async:!1,breaks:!1,extensions:null,gfm:!0,hooks:null,pedantic:!1,renderer:null,silent:!1,tokenizer:null,walkTokens:null}}function i(t){e.defaults=t}e.defaults={async:!1,breaks:!1,extensions:null,gfm:!0,hooks:null,pedantic:!1,renderer:null,silent:!1,tokenizer:null,walkTokens:null};const s=/[&<>"']/,n=new RegExp(s.source,"g"),r=/[<>"']|&(?!(#\d{1,7}|#[Xx][a-fA-F0-9]{1,6}|\w+);)/,o=new RegExp(r.source,"g"),a={"&":"&","<":"<",">":">",'"':""","'":"'"},l=e=>a[e];function c(e,t){if(t){if(s.test(e))return e.replace(n,l)}else if(r.test(e))return e.replace(o,l);return e}const h=/(^|[^\[])\^/g;function d(e,t){let i="string"===typeof e?e:e.source;t=t||"";const s={replace:(e,t)=>{let n="string"===typeof t?t:t.source;return n=n.replace(h,"$1"),i=i.replace(e,n),s},getRegex:()=>new RegExp(i,t)};return s}function u(e){try{e=encodeURI(e).replace(/%25/g,"%")}catch{return null}return e}const g={exec:()=>null};function p(e,t){const i=e.replace(/\|/g,((e,t,i)=>{let s=!1,n=t;for(;--n>=0&&"\\"===i[n];)s=!s;return s?"|":" |"})).split(/ \|/);let s=0;if(i[0].trim()||i.shift(),i.length>0&&!i[i.length-1].trim()&&i.pop(),t)if(i.length>t)i.splice(t);else for(;i.length0)return{type:"space",raw:t[0]}}code(e){const t=this.rules.block.code.exec(e);if(t){const e=t[0].replace(/^ {1,4}/gm,"");return{type:"code",raw:t[0],codeBlockStyle:"indented",text:this.options.pedantic?e:m(e,"\n")}}}fences(e){const t=this.rules.block.fences.exec(e);if(t){const e=t[0],i=function(e,t){const i=e.match(/^(\s+)(?:```)/);if(null===i)return t;const s=i[1];return t.split("\n").map((e=>{const t=e.match(/^\s+/);if(null===t)return e;const[i]=t;return i.length>=s.length?e.slice(s.length):e})).join("\n")}(e,t[3]||"");return{type:"code",raw:e,lang:t[2]?t[2].trim().replace(this.rules.inline.anyPunctuation,"$1"):t[2],text:i}}}heading(e){const t=this.rules.block.heading.exec(e);if(t){let e=t[2].trim();if(/#$/.test(e)){const t=m(e,"#");this.options.pedantic?e=t.trim():t&&!/ $/.test(t)||(e=t.trim())}return{type:"heading",raw:t[0],depth:t[1].length,text:e,tokens:this.lexer.inline(e)}}}hr(e){const t=this.rules.block.hr.exec(e);if(t)return{type:"hr",raw:m(t[0],"\n")}}blockquote(e){const t=this.rules.block.blockquote.exec(e);if(t){let e=m(t[0],"\n").split("\n"),i="",s="";const n=[];for(;e.length>0;){let t=!1;const r=[];let o;for(o=0;o/.test(e[o]))r.push(e[o]),t=!0;else{if(t)break;r.push(e[o])}e=e.slice(o);const a=r.join("\n"),l=a.replace(/\n {0,3}((?:=+|-+) *)(?=\n|$)/g,"\n $1").replace(/^ {0,3}>[ \t]?/gm,"");i=i?`${i}\n${a}`:a,s=s?`${s}\n${l}`:l;const c=this.lexer.state.top;if(this.lexer.state.top=!0,this.lexer.blockTokens(l,n,!0),this.lexer.state.top=c,0===e.length)break;const h=n[n.length-1];if("code"===h?.type)break;if("blockquote"===h?.type){const t=h,r=t.raw+"\n"+e.join("\n"),o=this.blockquote(r);n[n.length-1]=o,i=i.substring(0,i.length-t.raw.length)+o.raw,s=s.substring(0,s.length-t.text.length)+o.text;break}if("list"!==h?.type);else{const t=h,r=t.raw+"\n"+e.join("\n"),o=this.list(r);n[n.length-1]=o,i=i.substring(0,i.length-h.raw.length)+o.raw,s=s.substring(0,s.length-t.raw.length)+o.raw,e=r.substring(n[n.length-1].raw.length).split("\n")}}return{type:"blockquote",raw:i,tokens:n,text:s}}}list(e){let t=this.rules.block.list.exec(e);if(t){let i=t[1].trim();const s=i.length>1,n={type:"list",raw:"",ordered:s,start:s?+i.slice(0,-1):"",loose:!1,items:[]};i=s?`\\d{1,9}\\${i.slice(-1)}`:`\\${i}`,this.options.pedantic&&(i=s?i:"[*+-]");const r=new RegExp(`^( {0,3}${i})((?:[\t ][^\\n]*)?(?:\\n|$))`);let o=!1;for(;e;){let i=!1,s="",a="";if(!(t=r.exec(e)))break;if(this.rules.block.hr.test(e))break;s=t[0],e=e.substring(s.length);let l=t[2].split("\n",1)[0].replace(/^\t+/,(e=>" ".repeat(3*e.length))),c=e.split("\n",1)[0],h=!l.trim(),d=0;if(this.options.pedantic?(d=2,a=l.trimStart()):h?d=t[1].length+1:(d=t[2].search(/[^ ]/),d=d>4?1:d,a=l.slice(d),d+=t[1].length),h&&/^ *$/.test(c)&&(s+=c+"\n",e=e.substring(c.length+1),i=!0),!i){const t=new RegExp(`^ {0,${Math.min(3,d-1)}}(?:[*+-]|\\d{1,9}[.)])((?:[ \t][^\\n]*)?(?:\\n|$))`),i=new RegExp(`^ {0,${Math.min(3,d-1)}}((?:- *){3,}|(?:_ *){3,}|(?:\\* *){3,})(?:\\n+|$)`),n=new RegExp(`^ {0,${Math.min(3,d-1)}}(?:\`\`\`|~~~)`),r=new RegExp(`^ {0,${Math.min(3,d-1)}}#`);for(;e;){const o=e.split("\n",1)[0];if(c=o,this.options.pedantic&&(c=c.replace(/^ {1,4}(?=( {4})*[^ ])/g," ")),n.test(c))break;if(r.test(c))break;if(t.test(c))break;if(i.test(e))break;if(c.search(/[^ ]/)>=d||!c.trim())a+="\n"+c.slice(d);else{if(h)break;if(l.search(/[^ ]/)>=4)break;if(n.test(l))break;if(r.test(l))break;if(i.test(l))break;a+="\n"+c}h||c.trim()||(h=!0),s+=o+"\n",e=e.substring(o.length+1),l=c.slice(d)}}n.loose||(o?n.loose=!0:/\n *\n *$/.test(s)&&(o=!0));let u,g=null;this.options.gfm&&(g=/^\[[ xX]\] /.exec(a),g&&(u="[ ] "!==g[0],a=a.replace(/^\[[ xX]\] +/,""))),n.items.push({type:"list_item",raw:s,task:!!g,checked:u,loose:!1,text:a,tokens:[]}),n.raw+=s}n.items[n.items.length-1].raw=n.items[n.items.length-1].raw.trimEnd(),n.items[n.items.length-1].text=n.items[n.items.length-1].text.trimEnd(),n.raw=n.raw.trimEnd();for(let e=0;e"space"===e.type)),i=t.length>0&&t.some((e=>/\n.*\n/.test(e.raw)));n.loose=i}if(n.loose)for(let e=0;e$/,"$1").replace(this.rules.inline.anyPunctuation,"$1"):"",s=t[3]?t[3].substring(1,t[3].length-1).replace(this.rules.inline.anyPunctuation,"$1"):t[3];return{type:"def",tag:e,raw:t[0],href:i,title:s}}}table(e){const t=this.rules.block.table.exec(e);if(!t)return;if(!/[:|]/.test(t[2]))return;const i=p(t[1]),s=t[2].replace(/^\||\| *$/g,"").split("|"),n=t[3]&&t[3].trim()?t[3].replace(/\n[ \t]*$/,"").split("\n"):[],r={type:"table",raw:t[0],header:[],align:[],rows:[]};if(i.length===s.length){for(const e of s)/^ *-+: *$/.test(e)?r.align.push("right"):/^ *:-+: *$/.test(e)?r.align.push("center"):/^ *:-+ *$/.test(e)?r.align.push("left"):r.align.push(null);for(let e=0;e({text:e,tokens:this.lexer.inline(e),header:!1,align:r.align[t]}))));return r}}lheading(e){const t=this.rules.block.lheading.exec(e);if(t)return{type:"heading",raw:t[0],depth:"="===t[2].charAt(0)?1:2,text:t[1],tokens:this.lexer.inline(t[1])}}paragraph(e){const t=this.rules.block.paragraph.exec(e);if(t){const e="\n"===t[1].charAt(t[1].length-1)?t[1].slice(0,-1):t[1];return{type:"paragraph",raw:t[0],text:e,tokens:this.lexer.inline(e)}}}text(e){const t=this.rules.block.text.exec(e);if(t)return{type:"text",raw:t[0],text:t[0],tokens:this.lexer.inline(t[0])}}escape(e){const t=this.rules.inline.escape.exec(e);if(t)return{type:"escape",raw:t[0],text:c(t[1])}}tag(e){const t=this.rules.inline.tag.exec(e);if(t)return!this.lexer.state.inLink&&/^/i.test(t[0])&&(this.lexer.state.inLink=!1),!this.lexer.state.inRawBlock&&/^<(pre|code|kbd|script)(\s|>)/i.test(t[0])?this.lexer.state.inRawBlock=!0:this.lexer.state.inRawBlock&&/^<\/(pre|code|kbd|script)(\s|>)/i.test(t[0])&&(this.lexer.state.inRawBlock=!1),{type:"html",raw:t[0],inLink:this.lexer.state.inLink,inRawBlock:this.lexer.state.inRawBlock,block:!1,text:t[0]}}link(e){const t=this.rules.inline.link.exec(e);if(t){const e=t[2].trim();if(!this.options.pedantic&&/^$/.test(e))return;const t=m(e.slice(0,-1),"\\");if((e.length-t.length)%2===0)return}else{const e=function(e,t){if(-1===e.indexOf(t[1]))return-1;let i=0;for(let s=0;s-1){const i=(0===t[0].indexOf("!")?5:4)+t[1].length+e;t[2]=t[2].substring(0,e),t[0]=t[0].substring(0,i).trim(),t[3]=""}}let i=t[2],s="";if(this.options.pedantic){const e=/^([^'"]*[^\s])\s+(['"])(.*)\2/.exec(i);e&&(i=e[1],s=e[3])}else s=t[3]?t[3].slice(1,-1):"";return i=i.trim(),/^$/.test(e)?i.slice(1):i.slice(1,-1)),f(t,{href:i?i.replace(this.rules.inline.anyPunctuation,"$1"):i,title:s?s.replace(this.rules.inline.anyPunctuation,"$1"):s},t[0],this.lexer)}}reflink(e,t){let i;if((i=this.rules.inline.reflink.exec(e))||(i=this.rules.inline.nolink.exec(e))){const e=t[(i[2]||i[1]).replace(/\s+/g," ").toLowerCase()];if(!e){const e=i[0].charAt(0);return{type:"text",raw:e,text:e}}return f(i,e,i[0],this.lexer)}}emStrong(e,t,i=""){let s=this.rules.inline.emStrongLDelim.exec(e);if(s&&(!s[3]||!i.match(/[\p{L}\p{N}]/u))&&(!s[1]&&!s[2]||!i||this.rules.inline.punctuation.exec(i))){const i=[...s[0]].length-1;let n,r,o=i,a=0;const l="*"===s[0][0]?this.rules.inline.emStrongRDelimAst:this.rules.inline.emStrongRDelimUnd;for(l.lastIndex=0,t=t.slice(-1*e.length+i);null!=(s=l.exec(t));){if(n=s[1]||s[2]||s[3]||s[4]||s[5]||s[6],!n)continue;if(r=[...n].length,s[3]||s[4]){o+=r;continue}if((s[5]||s[6])&&i%3&&!((i+r)%3)){a+=r;continue}if(o-=r,o>0)continue;r=Math.min(r,r+o+a);const t=[...s[0]][0].length,l=e.slice(0,i+s.index+t+r);if(Math.min(i,r)%2){const e=l.slice(1,-1);return{type:"em",raw:l,text:e,tokens:this.lexer.inlineTokens(e)}}const c=l.slice(2,-2);return{type:"strong",raw:l,text:c,tokens:this.lexer.inlineTokens(c)}}}}codespan(e){const t=this.rules.inline.code.exec(e);if(t){let e=t[2].replace(/\n/g," ");const i=/[^ ]/.test(e),s=/^ /.test(e)&&/ $/.test(e);return i&&s&&(e=e.substring(1,e.length-1)),e=c(e,!0),{type:"codespan",raw:t[0],text:e}}}br(e){const t=this.rules.inline.br.exec(e);if(t)return{type:"br",raw:t[0]}}del(e){const t=this.rules.inline.del.exec(e);if(t)return{type:"del",raw:t[0],text:t[2],tokens:this.lexer.inlineTokens(t[2])}}autolink(e){const t=this.rules.inline.autolink.exec(e);if(t){let e,i;return"@"===t[2]?(e=c(t[1]),i="mailto:"+e):(e=c(t[1]),i=e),{type:"link",raw:t[0],text:e,href:i,tokens:[{type:"text",raw:e,text:e}]}}}url(e){let t;if(t=this.rules.inline.url.exec(e)){let e,i;if("@"===t[2])e=c(t[0]),i="mailto:"+e;else{let s;do{s=t[0],t[0]=this.rules.inline._backpedal.exec(t[0])?.[0]??""}while(s!==t[0]);e=c(t[0]),i="www."===t[1]?"http://"+t[0]:t[0]}return{type:"link",raw:t[0],text:e,href:i,tokens:[{type:"text",raw:e,text:e}]}}}inlineText(e){const t=this.rules.inline.text.exec(e);if(t){let e;return e=this.lexer.state.inRawBlock?t[0]:c(t[0]),{type:"text",raw:t[0],text:e}}}}const v=/^ {0,3}((?:-[\t ]*){3,}|(?:_[ \t]*){3,}|(?:\*[ \t]*){3,})(?:\n+|$)/,C=/(?:[*+-]|\d{1,9}[.)])/,b=d(/^(?!bull |blockCode|fences|blockquote|heading|html)((?:.|\n(?!\s*?\n|bull |blockCode|fences|blockquote|heading|html))+?)\n {0,3}(=+|-+) *(?:\n+|$)/).replace(/bull/g,C).replace(/blockCode/g,/ {4}/).replace(/fences/g,/ {0,3}(?:`{3,}|~{3,})/).replace(/blockquote/g,/ {0,3}>/).replace(/heading/g,/ {0,3}#{1,6}/).replace(/html/g,/ {0,3}<[^\n>]+>\n/).getRegex(),E=/^([^\n]+(?:\n(?!hr|heading|lheading|blockquote|fences|list|html|table| +\n)[^\n]+)*)/,S=/(?!\s*\])(?:\\.|[^\[\]\\])+/,y=d(/^ {0,3}\[(label)\]: *(?:\n *)?([^<\s][^\s]*|<.*?>)(?:(?: +(?:\n *)?| *\n *)(title))? *(?:\n+|$)/).replace("label",S).replace("title",/(?:"(?:\\"?|[^"\\])*"|'[^'\n]*(?:\n[^'\n]+)*\n?'|\([^()]*\))/).getRegex(),w=d(/^( {0,3}bull)([ \t][^\n]+?)?(?:\n|$)/).replace(/bull/g,C).getRegex(),L="address|article|aside|base|basefont|blockquote|body|caption|center|col|colgroup|dd|details|dialog|dir|div|dl|dt|fieldset|figcaption|figure|footer|form|frame|frameset|h[1-6]|head|header|hr|html|iframe|legend|li|link|main|menu|menuitem|meta|nav|noframes|ol|optgroup|option|p|param|search|section|summary|table|tbody|td|tfoot|th|thead|title|tr|track|ul",R=/|$))/,T=d("^ {0,3}(?:<(script|pre|style|textarea)[\\s>][\\s\\S]*?(?:[^\\n]*\\n+|$)|comment[^\\n]*(\\n+|$)|<\\?[\\s\\S]*?(?:\\?>\\n*|$)|\\n*|$)|\\n*|$)|)[\\s\\S]*?(?:(?:\\n *)+\\n|$)|<(?!script|pre|style|textarea)([a-z][\\w-]*)(?:attribute)*? */?>(?=[ \\t]*(?:\\n|$))[\\s\\S]*?(?:(?:\\n *)+\\n|$)|(?=[ \\t]*(?:\\n|$))[\\s\\S]*?(?:(?:\\n *)+\\n|$))","i").replace("comment",R).replace("tag",L).replace("attribute",/ +[a-zA-Z:_][\w.:-]*(?: *= *"[^"\n]*"| *= *'[^'\n]*'| *= *[^\s"'=<>`]+)?/).getRegex(),x=d(E).replace("hr",v).replace("heading"," {0,3}#{1,6}(?:\\s|$)").replace("|lheading","").replace("|table","").replace("blockquote"," {0,3}>").replace("fences"," {0,3}(?:`{3,}(?=[^`\\n]*\\n)|~{3,})[^\\n]*\\n").replace("list"," {0,3}(?:[*+-]|1[.)]) ").replace("html",")|<(?:script|pre|style|textarea|!--)").replace("tag",L).getRegex(),k={blockquote:d(/^( {0,3}> ?(paragraph|[^\n]*)(?:\n|$))+/).replace("paragraph",x).getRegex(),code:/^( {4}[^\n]+(?:\n(?: *(?:\n|$))*)?)+/,def:y,fences:/^ {0,3}(`{3,}(?=[^`\n]*(?:\n|$))|~{3,})([^\n]*)(?:\n|$)(?:|([\s\S]*?)(?:\n|$))(?: {0,3}\1[~`]* *(?=\n|$)|$)/,heading:/^ {0,3}(#{1,6})(?=\s|$)(.*)(?:\n+|$)/,hr:v,html:T,lheading:b,list:w,newline:/^(?: *(?:\n|$))+/,paragraph:x,table:g,text:/^[^\n]+/},A=d("^ *([^\\n ].*)\\n {0,3}((?:\\| *)?:?-+:? *(?:\\| *:?-+:? *)*(?:\\| *)?)(?:\\n((?:(?! *\\n|hr|heading|blockquote|code|fences|list|html).*(?:\\n|$))*)\\n*|$)").replace("hr",v).replace("heading"," {0,3}#{1,6}(?:\\s|$)").replace("blockquote"," {0,3}>").replace("code"," {4}[^\\n]").replace("fences"," {0,3}(?:`{3,}(?=[^`\\n]*\\n)|~{3,})[^\\n]*\\n").replace("list"," {0,3}(?:[*+-]|1[.)]) ").replace("html",")|<(?:script|pre|style|textarea|!--)").replace("tag",L).getRegex(),N={...k,table:A,paragraph:d(E).replace("hr",v).replace("heading"," {0,3}#{1,6}(?:\\s|$)").replace("|lheading","").replace("table",A).replace("blockquote"," {0,3}>").replace("fences"," {0,3}(?:`{3,}(?=[^`\\n]*\\n)|~{3,})[^\\n]*\\n").replace("list"," {0,3}(?:[*+-]|1[.)]) ").replace("html",")|<(?:script|pre|style|textarea|!--)").replace("tag",L).getRegex()},I={...k,html:d("^ *(?:comment *(?:\\n|\\s*$)|<(tag)[\\s\\S]+? *(?:\\n{2,}|\\s*$)|\\s]*)*?/?> *(?:\\n{2,}|\\s*$))").replace("comment",R).replace(/tag/g,"(?!(?:a|em|strong|small|s|cite|q|dfn|abbr|data|time|code|var|samp|kbd|sub|sup|i|b|u|mark|ruby|rt|rp|bdi|bdo|span|br|wbr|ins|del|img)\\b)\\w+(?!:|[^\\w\\s@]*@)\\b").getRegex(),def:/^ *\[([^\]]+)\]: *]+)>?(?: +(["(][^\n]+[")]))? *(?:\n+|$)/,heading:/^(#{1,6})(.*)(?:\n+|$)/,fences:g,lheading:/^(.+?)\n {0,3}(=+|-+) *(?:\n+|$)/,paragraph:d(E).replace("hr",v).replace("heading"," *#{1,6} *[^\n]").replace("lheading",b).replace("|table","").replace("blockquote"," {0,3}>").replace("|fences","").replace("|list","").replace("|html","").replace("|tag","").getRegex()},O=/^\\([!"#$%&'()*+,\-./:;<=>?@\[\]\\^_`{|}~])/,D=/^( {2,}|\\)\n(?!\s*$)/,M="\\p{P}\\p{S}",P=d(/^((?![*_])[\spunctuation])/,"u").replace(/punctuation/g,M).getRegex(),F=d(/^(?:\*+(?:((?!\*)[punct])|[^\s*]))|^_+(?:((?!_)[punct])|([^\s_]))/,"u").replace(/punct/g,M).getRegex(),U=d("^[^_*]*?__[^_*]*?\\*[^_*]*?(?=__)|[^*]+(?=[^*])|(?!\\*)[punct](\\*+)(?=[\\s]|$)|[^punct\\s](\\*+)(?!\\*)(?=[punct\\s]|$)|(?!\\*)[punct\\s](\\*+)(?=[^punct\\s])|[\\s](\\*+)(?!\\*)(?=[punct])|(?!\\*)[punct](\\*+)(?!\\*)(?=[punct])|[^punct\\s](\\*+)(?=[^punct\\s])","gu").replace(/punct/g,M).getRegex(),H=d("^[^_*]*?\\*\\*[^_*]*?_[^_*]*?(?=\\*\\*)|[^_]+(?=[^_])|(?!_)[punct](_+)(?=[\\s]|$)|[^punct\\s](_+)(?!_)(?=[punct\\s]|$)|(?!_)[punct\\s](_+)(?=[^punct\\s])|[\\s](_+)(?!_)(?=[punct])|(?!_)[punct](_+)(?!_)(?=[punct])","gu").replace(/punct/g,M).getRegex(),B=d(/\\([punct])/,"gu").replace(/punct/g,M).getRegex(),W=d(/^<(scheme:[^\s\x00-\x1f<>]*|email)>/).replace("scheme",/[a-zA-Z][a-zA-Z0-9+.-]{1,31}/).replace("email",/[a-zA-Z0-9.!#$%&'*+/=?^_`{|}~-]+(@)[a-zA-Z0-9](?:[a-zA-Z0-9-]{0,61}[a-zA-Z0-9])?(?:\.[a-zA-Z0-9](?:[a-zA-Z0-9-]{0,61}[a-zA-Z0-9])?)+(?![-_])/).getRegex(),V=d(R).replace("(?:--\x3e|$)","--\x3e").getRegex(),z=d("^comment|^|^<[a-zA-Z][\\w-]*(?:attribute)*?\\s*/?>|^<\\?[\\s\\S]*?\\?>|^|^").replace("comment",V).replace("attribute",/\s+[a-zA-Z:_][\w.:-]*(?:\s*=\s*"[^"]*"|\s*=\s*'[^']*'|\s*=\s*[^\s"'=<>`]+)?/).getRegex(),G=/(?:\[(?:\\.|[^\[\]\\])*\]|\\.|`[^`]*`|[^\[\]\\`])*?/,j=d(/^!?\[(label)\]\(\s*(href)(?:\s+(title))?\s*\)/).replace("label",G).replace("href",/<(?:\\.|[^\n<>\\])+>|[^\s\x00-\x1f]*/).replace("title",/"(?:\\"?|[^"\\])*"|'(?:\\'?|[^'\\])*'|\((?:\\\)?|[^)\\])*\)/).getRegex(),K=d(/^!?\[(label)\]\[(ref)\]/).replace("label",G).replace("ref",S).getRegex(),Y=d(/^!?\[(ref)\](?:\[\])?/).replace("ref",S).getRegex(),q={_backpedal:g,anyPunctuation:B,autolink:W,blockSkip:/\[[^[\]]*?\]\([^\(\)]*?\)|`[^`]*?`|<[^<>]*?>/g,br:D,code:/^(`+)([^`]|[^`][\s\S]*?[^`])\1(?!`)/,del:g,emStrongLDelim:F,emStrongRDelimAst:U,emStrongRDelimUnd:H,escape:O,link:j,nolink:Y,punctuation:P,reflink:K,reflinkSearch:d("reflink|nolink(?!\\()","g").replace("reflink",K).replace("nolink",Y).getRegex(),tag:z,text:/^(`+|[^`])(?:(?= {2,}\n)|[\s\S]*?(?:(?=[\\t+" ".repeat(i.length)));e;)if(!(this.options.extensions&&this.options.extensions.block&&this.options.extensions.block.some((i=>!!(s=i.call({lexer:this},e,t))&&(e=e.substring(s.raw.length),t.push(s),!0)))))if(s=this.tokenizer.space(e))e=e.substring(s.raw.length),1===s.raw.length&&t.length>0?t[t.length-1].raw+="\n":t.push(s);else if(s=this.tokenizer.code(e))e=e.substring(s.raw.length),n=t[t.length-1],!n||"paragraph"!==n.type&&"text"!==n.type?t.push(s):(n.raw+="\n"+s.raw,n.text+="\n"+s.text,this.inlineQueue[this.inlineQueue.length-1].src=n.text);else if(s=this.tokenizer.fences(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.heading(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.hr(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.blockquote(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.list(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.html(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.def(e))e=e.substring(s.raw.length),n=t[t.length-1],!n||"paragraph"!==n.type&&"text"!==n.type?this.tokens.links[s.tag]||(this.tokens.links[s.tag]={href:s.href,title:s.title}):(n.raw+="\n"+s.raw,n.text+="\n"+s.raw,this.inlineQueue[this.inlineQueue.length-1].src=n.text);else if(s=this.tokenizer.table(e))e=e.substring(s.raw.length),t.push(s);else if(s=this.tokenizer.lheading(e))e=e.substring(s.raw.length),t.push(s);else{if(r=e,this.options.extensions&&this.options.extensions.startBlock){let t=1/0;const i=e.slice(1);let s;this.options.extensions.startBlock.forEach((e=>{s=e.call({lexer:this},i),"number"===typeof s&&s>=0&&(t=Math.min(t,s))})),t<1/0&&t>=0&&(r=e.substring(0,t+1))}if(this.state.top&&(s=this.tokenizer.paragraph(r)))n=t[t.length-1],i&&"paragraph"===n?.type?(n.raw+="\n"+s.raw,n.text+="\n"+s.text,this.inlineQueue.pop(),this.inlineQueue[this.inlineQueue.length-1].src=n.text):t.push(s),i=r.length!==e.length,e=e.substring(s.raw.length);else if(s=this.tokenizer.text(e))e=e.substring(s.raw.length),n=t[t.length-1],n&&"text"===n.type?(n.raw+="\n"+s.raw,n.text+="\n"+s.text,this.inlineQueue.pop(),this.inlineQueue[this.inlineQueue.length-1].src=n.text):t.push(s);else if(e){const t="Infinite loop on byte: "+e.charCodeAt(0);if(this.options.silent){console.error(t);break}throw new Error(t)}}return this.state.top=!0,t}inline(e,t=[]){return this.inlineQueue.push({src:e,tokens:t}),t}inlineTokens(e,t=[]){let i,s,n,r,o,a,l=e;if(this.tokens.links){const e=Object.keys(this.tokens.links);if(e.length>0)for(;null!=(r=this.tokenizer.rules.inline.reflinkSearch.exec(l));)e.includes(r[0].slice(r[0].lastIndexOf("[")+1,-1))&&(l=l.slice(0,r.index)+"["+"a".repeat(r[0].length-2)+"]"+l.slice(this.tokenizer.rules.inline.reflinkSearch.lastIndex))}for(;null!=(r=this.tokenizer.rules.inline.blockSkip.exec(l));)l=l.slice(0,r.index)+"["+"a".repeat(r[0].length-2)+"]"+l.slice(this.tokenizer.rules.inline.blockSkip.lastIndex);for(;null!=(r=this.tokenizer.rules.inline.anyPunctuation.exec(l));)l=l.slice(0,r.index)+"++"+l.slice(this.tokenizer.rules.inline.anyPunctuation.lastIndex);for(;e;)if(o||(a=""),o=!1,!(this.options.extensions&&this.options.extensions.inline&&this.options.extensions.inline.some((s=>!!(i=s.call({lexer:this},e,t))&&(e=e.substring(i.raw.length),t.push(i),!0)))))if(i=this.tokenizer.escape(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.tag(e))e=e.substring(i.raw.length),s=t[t.length-1],s&&"text"===i.type&&"text"===s.type?(s.raw+=i.raw,s.text+=i.text):t.push(i);else if(i=this.tokenizer.link(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.reflink(e,this.tokens.links))e=e.substring(i.raw.length),s=t[t.length-1],s&&"text"===i.type&&"text"===s.type?(s.raw+=i.raw,s.text+=i.text):t.push(i);else if(i=this.tokenizer.emStrong(e,l,a))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.codespan(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.br(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.del(e))e=e.substring(i.raw.length),t.push(i);else if(i=this.tokenizer.autolink(e))e=e.substring(i.raw.length),t.push(i);else if(this.state.inLink||!(i=this.tokenizer.url(e))){if(n=e,this.options.extensions&&this.options.extensions.startInline){let t=1/0;const i=e.slice(1);let s;this.options.extensions.startInline.forEach((e=>{s=e.call({lexer:this},i),"number"===typeof s&&s>=0&&(t=Math.min(t,s))})),t<1/0&&t>=0&&(n=e.substring(0,t+1))}if(i=this.tokenizer.inlineText(n))e=e.substring(i.raw.length),"_"!==i.raw.slice(-1)&&(a=i.raw.slice(-1)),o=!0,s=t[t.length-1],s&&"text"===s.type?(s.raw+=i.raw,s.text+=i.text):t.push(i);else if(e){const t="Infinite loop on byte: "+e.charCodeAt(0);if(this.options.silent){console.error(t);break}throw new Error(t)}}else e=e.substring(i.raw.length),t.push(i);return t}}class te{options;parser;constructor(t){this.options=t||e.defaults}space(e){return""}code({text:e,lang:t,escaped:i}){const s=(t||"").match(/^\S*/)?.[0],n=e.replace(/\n$/,"")+"\n";return s?'
    '+(i?n:c(n,!0))+"
    \n":"
    "+(i?n:c(n,!0))+"
    \n"}blockquote({tokens:e}){return`
    \n${this.parser.parse(e)}
    \n`}html({text:e}){return e}heading({tokens:e,depth:t}){return`${this.parser.parseInline(e)}\n`}hr(e){return"
    \n"}list(e){const t=e.ordered,i=e.start;let s="";for(let r=0;r\n"+s+"\n"}listitem(e){let t="";if(e.task){const i=this.checkbox({checked:!!e.checked});e.loose?e.tokens.length>0&&"paragraph"===e.tokens[0].type?(e.tokens[0].text=i+" "+e.tokens[0].text,e.tokens[0].tokens&&e.tokens[0].tokens.length>0&&"text"===e.tokens[0].tokens[0].type&&(e.tokens[0].tokens[0].text=i+" "+e.tokens[0].tokens[0].text)):e.tokens.unshift({type:"text",raw:i+" ",text:i+" "}):t+=i+" "}return t+=this.parser.parse(e.tokens,!!e.loose),`
  • ${t}
  • \n`}checkbox({checked:e}){return"'}paragraph({tokens:e}){return`

    ${this.parser.parseInline(e)}

    \n`}table(e){let t="",i="";for(let n=0;n${s}`),"\n\n"+t+"\n"+s+"
    \n"}tablerow({text:e}){return`\n${e}\n`}tablecell(e){const t=this.parser.parseInline(e.tokens),i=e.header?"th":"td";return(e.align?`<${i} align="${e.align}">`:`<${i}>`)+t+`\n`}strong({tokens:e}){return`${this.parser.parseInline(e)}`}em({tokens:e}){return`${this.parser.parseInline(e)}`}codespan({text:e}){return`${e}`}br(e){return"
    "}del({tokens:e}){return`${this.parser.parseInline(e)}`}link({href:e,title:t,tokens:i}){const s=this.parser.parseInline(i),n=u(e);if(null===n)return s;let r='
    ",r}image({href:e,title:t,text:i}){const s=u(e);if(null===s)return i;let n=`${i}{const n=e[s].flat(1/0);i=i.concat(this.walkTokens(n,t))})):e.tokens&&(i=i.concat(this.walkTokens(e.tokens,t)))}}return i}use(...e){const t=this.defaults.extensions||{renderers:{},childTokens:{}};return e.forEach((e=>{const i={...e};if(i.async=this.defaults.async||i.async||!1,e.extensions&&(e.extensions.forEach((e=>{if(!e.name)throw new Error("extension name required");if("renderer"in e){const i=t.renderers[e.name];t.renderers[e.name]=i?function(...t){let s=e.renderer.apply(this,t);return!1===s&&(s=i.apply(this,t)),s}:e.renderer}if("tokenizer"in e){if(!e.level||"block"!==e.level&&"inline"!==e.level)throw new Error("extension level must be 'block' or 'inline'");const i=t[e.level];i?i.unshift(e.tokenizer):t[e.level]=[e.tokenizer],e.start&&("block"===e.level?t.startBlock?t.startBlock.push(e.start):t.startBlock=[e.start]:"inline"===e.level&&(t.startInline?t.startInline.push(e.start):t.startInline=[e.start]))}"childTokens"in e&&e.childTokens&&(t.childTokens[e.name]=e.childTokens)})),i.extensions=t),e.renderer){const t=this.defaults.renderer||new te(this.defaults);for(const i in e.renderer){if(!(i in t))throw new Error(`renderer '${i}' does not exist`);if(["options","parser"].includes(i))continue;const s=i,n=e.renderer[s],r=t[s];t[s]=(...e)=>{let i=n.apply(t,e);return!1===i&&(i=r.apply(t,e)),i||""}}i.renderer=t}if(e.tokenizer){const t=this.defaults.tokenizer||new _(this.defaults);for(const i in e.tokenizer){if(!(i in t))throw new Error(`tokenizer '${i}' does not exist`);if(["options","rules","lexer"].includes(i))continue;const s=i,n=e.tokenizer[s],r=t[s];t[s]=(...e)=>{let i=n.apply(t,e);return!1===i&&(i=r.apply(t,e)),i}}i.tokenizer=t}if(e.hooks){const t=this.defaults.hooks||new ne;for(const i in e.hooks){if(!(i in t))throw new Error(`hook '${i}' does not exist`);if("options"===i)continue;const s=i,n=e.hooks[s],r=t[s];ne.passThroughHooks.has(i)?t[s]=e=>{if(this.defaults.async)return Promise.resolve(n.call(t,e)).then((e=>r.call(t,e)));const i=n.call(t,e);return r.call(t,i)}:t[s]=(...e)=>{let i=n.apply(t,e);return!1===i&&(i=r.apply(t,e)),i}}i.hooks=t}if(e.walkTokens){const t=this.defaults.walkTokens,s=e.walkTokens;i.walkTokens=function(e){let i=[];return i.push(s.call(this,e)),t&&(i=i.concat(t.call(this,e))),i}}this.defaults={...this.defaults,...i}})),this}setOptions(e){return this.defaults={...this.defaults,...e},this}lexer(e,t){return ee.lex(e,t??this.defaults)}parser(e,t){return se.parse(e,t??this.defaults)}parseMarkdown(e,t){return(i,s)=>{const n={...s},r={...this.defaults,...n},o=this.onError(!!r.silent,!!r.async);if(!0===this.defaults.async&&!1===n.async)return o(new Error("marked(): The async option was set to true by an extension. Remove async: false from the parse options object to return a Promise."));if("undefined"===typeof i||null===i)return o(new Error("marked(): input parameter is undefined or null"));if("string"!==typeof i)return o(new Error("marked(): input parameter is of type "+Object.prototype.toString.call(i)+", string expected"));if(r.hooks&&(r.hooks.options=r),r.async)return Promise.resolve(r.hooks?r.hooks.preprocess(i):i).then((t=>e(t,r))).then((e=>r.hooks?r.hooks.processAllTokens(e):e)).then((e=>r.walkTokens?Promise.all(this.walkTokens(e,r.walkTokens)).then((()=>e)):e)).then((e=>t(e,r))).then((e=>r.hooks?r.hooks.postprocess(e):e)).catch(o);try{r.hooks&&(i=r.hooks.preprocess(i));let s=e(i,r);r.hooks&&(s=r.hooks.processAllTokens(s)),r.walkTokens&&this.walkTokens(s,r.walkTokens);let n=t(s,r);return r.hooks&&(n=r.hooks.postprocess(n)),n}catch(a){return o(a)}}}onError(e,t){return i=>{if(i.message+="\nPlease report this to https://github.com/markedjs/marked.",e){const e="

    An error occurred:

    "+c(i.message+"",!0)+"
    ";return t?Promise.resolve(e):e}if(t)return Promise.reject(i);throw i}}}const oe=new re;function ae(e,t){return oe.parse(e,t)}ae.options=ae.setOptions=function(e){return oe.setOptions(e),ae.defaults=oe.defaults,i(ae.defaults),ae},ae.getDefaults=t,ae.defaults=e.defaults,ae.use=function(...e){return oe.use(...e),ae.defaults=oe.defaults,i(ae.defaults),ae},ae.walkTokens=function(e,t){return oe.walkTokens(e,t)},ae.parseInline=oe.parseInline,ae.Parser=se,ae.parser=se.parse,ae.Renderer=te,ae.TextRenderer=ie,ae.Lexer=ee,ae.lexer=ee.lex,ae.Tokenizer=_,ae.Hooks=ne,ae.parse=ae;const le=ae.options,ce=ae.setOptions,he=ae.use,de=ae.walkTokens,ue=ae.parseInline,ge=ae,pe=se.parse,me=ee.lex;e.Hooks=ne,e.Lexer=ee,e.Marked=re,e.Parser=se,e.Renderer=te,e.TextRenderer=ie,e.Tokenizer=_,e.getDefaults=t,e.lexer=me,e.marked=ae,e.options=le,e.parse=ge,e.parseInline=ue,e.parser=pe,e.setOptions=ce,e.use=he,e.walkTokens=de},e.amd?e(0,i):"object"===typeof exports?i(exports):i((t="undefined"!==typeof globalThis?globalThis:t||self).marked={})}();_.Hooks||exports.Hooks,_.Lexer||exports.Lexer,_.Marked||exports.Marked,_.Parser||exports.Parser;var v=_.Renderer||exports.Renderer,C=(_.TextRenderer||exports.TextRenderer,_.Tokenizer||exports.Tokenizer,_.defaults||exports.defaults),b=(_.getDefaults||exports.getDefaults,_.lexer||exports.lexer),E=(_.marked||exports.marked,_.options||exports.options,_.parse||exports.parse),S=(_.parseInline||exports.parseInline,_.parser||exports.parser),y=(_.setOptions||exports.setOptions,_.use||exports.use,_.walkTokens||exports.walkTokens,i(908)),w=i(36456),L=i(10146),R=i(89403),T=i(91508),x=i(79400);const k=Object.freeze({image:({href:e,title:t,text:i})=>{let s=[],n=[];return e&&(({href:e,dimensions:s}=(0,u.nI)(e)),n.push(`src="${(0,u.oO)(e)}"`)),i&&n.push(`alt="${(0,u.oO)(i)}"`),t&&n.push(`title="${(0,u.oO)(t)}"`),s.length&&(n=n.concat(s)),""},paragraph({tokens:e}){return`

    ${this.parser.parseInline(e)}

    `},link({href:e,title:t,tokens:i}){let s=this.parser.parseInline(i);return"string"!==typeof e?"":(e===s&&(s=(0,u._W)(s)),t="string"===typeof t?(0,u.oO)((0,u._W)(t)):"",`
    /g,">").replace(/"/g,""").replace(/'/g,"'")}" title="${t||e}" draggable="false">${s}`)}});function A(e,t={},i={}){const n=new f.Cm;let u=!1;const m=(0,o.n)(t),_=function(t){let i;try{i=(0,y.qg)(decodeURIComponent(t))}catch(s){}return i?(i=(0,L.PI)(i,(t=>e.uris&&e.uris[t]?x.r.revive(e.uris[t]):void 0)),encodeURIComponent(JSON.stringify(i))):t},R=function(t,i){const s=e.uris&&e.uris[t];let n=x.r.revive(s);return i?t.startsWith(w.ny.data+":")?t:(n||(n=x.r.parse(t)),w.zl.uriToBrowserUri(n).toString(!0)):n?x.r.parse(t).toString()===n.toString()?t:(n.query&&(n=n.with({query:_(n.query)})),n.toString()):t},A=new v;A.image=k.image,A.link=k.link,A.paragraph=k.paragraph;const O=[],M=[];if(t.codeBlockRendererSync?A.code=({text:e,lang:i})=>{const s=p.r.nextId(),n=t.codeBlockRendererSync(N(i),e);return M.push([s,n]),`
    ${(0,T.ih)(e)}
    `}:t.codeBlockRenderer&&(A.code=({text:e,lang:i})=>{const s=p.r.nextId(),n=t.codeBlockRenderer(N(i),e);return O.push(n.then((e=>[s,e]))),`
    ${(0,T.ih)(e)}
    `}),t.actionHandler){const i=function(i){let s=i.target;if("A"===s.tagName||(s=s.parentElement,s&&"A"===s.tagName))try{let n=s.dataset.href;n&&(e.baseUri&&(n=I(x.r.from(e.baseUri),n)),t.actionHandler.callback(n,i))}catch(n){(0,h.dz)(n)}finally{i.preventDefault()}},n=t.actionHandler.disposables.add(new r.f(m,"click")),o=t.actionHandler.disposables.add(new r.f(m,"auxclick"));t.actionHandler.disposables.add(d.Jh.any(n.event,o.event)((e=>{const t=new l.P(s.zk(m),e);(t.leftButton||t.middleButton)&&i(t)}))),t.actionHandler.disposables.add(s.ko(m,"keydown",(e=>{const t=new a.Z(e);(t.equals(10)||t.equals(3))&&i(t)})))}e.supportHtml||(A.html=({text:i})=>{if(t.sanitizerOptions?.replaceWithPlaintext)return(0,T.ih)(i);return(e.isTrusted?i.match(/^(]+>)|(<\/\s*span>)$/):void 0)?i:""}),i.renderer=A;let P,F=e.value??"";if(F.length>1e5&&(F=`${F.substr(0,1e5)}\u2026`),e.supportThemeIcons&&(F=(0,g.sA)(F)),t.fillInIncompleteTokens){const e={...C,...i},t=function(e){for(let t=0;t"string"===typeof e?e:e.outerHTML)).join("")}const U=(new DOMParser).parseFromString(D({isTrusted:e.isTrusted,...t.sanitizerOptions},P),"text/html");if(U.body.querySelectorAll("img, audio, video, source").forEach((i=>{const n=i.getAttribute("src");if(n){let o=n;try{e.baseUri&&(o=I(x.r.from(e.baseUri),o))}catch(r){}if(i.setAttribute("src",R(o,!0)),t.remoteImageIsAllowed){const e=x.r.parse(o);e.scheme===w.ny.file||e.scheme===w.ny.data||t.remoteImageIsAllowed(e)||i.replaceWith(s.$("",void 0,i.outerHTML))}}})),U.body.querySelectorAll("a").forEach((t=>{const i=t.getAttribute("href");if(t.setAttribute("href",""),!i||/^data:|javascript:/i.test(i)||/^command:/i.test(i)&&!e.isTrusted||/^command:(\/\/\/)?_workbench\.downloadResource/i.test(i))t.replaceWith(...t.childNodes);else{let s=R(i,!1);e.baseUri&&(s=I(x.r.from(e.baseUri),i)),t.dataset.href=s}})),m.innerHTML=D({isTrusted:e.isTrusted,...t.sanitizerOptions},U.body.innerHTML),O.length>0)Promise.all(O).then((e=>{if(u)return;const i=new Map(e),n=m.querySelectorAll("div[data-code]");for(const t of n){const e=i.get(t.dataset.code??"");e&&s.Ln(t,e)}t.asyncRenderCallback?.()}));else if(M.length>0){const e=new Map(M),t=m.querySelectorAll("div[data-code]");for(const i of t){const t=e.get(i.dataset.code??"");t&&s.Ln(i,t)}}if(t.asyncRenderCallback)for(const r of m.getElementsByTagName("img")){const e=n.add(s.ko(r,"load",(()=>{e.dispose(),t.asyncRenderCallback()})))}return{element:m,dispose:()=>{u=!0,n.dispose()}}}function N(e){if(!e)return"";const t=e.split(/[\s+|:|,|\{|\?]/,1);return t.length?t[0]:e}function I(e,t){return/^\w[\w\d+.-]*:/.test(t)?t:e.path.endsWith("/")?(0,R.o1)(e,t).toString():(0,R.o1)((0,R.pD)(e),t).toString()}const O=["area","base","br","col","command","embed","hr","img","input","keygen","link","meta","param","source","track","wbr"];function D(e,t){const{config:i,allowedSchemes:r}=function(e){const t=[w.ny.http,w.ny.https,w.ny.mailto,w.ny.data,w.ny.file,w.ny.vscodeFileResource,w.ny.vscodeRemote,w.ny.vscodeRemoteResource];e.isTrusted&&t.push(w.ny.command);return{config:{ALLOWED_TAGS:e.allowedTags??[...s.TT],ALLOWED_ATTR:M,ALLOW_UNKNOWN_PROTOCOLS:!0},allowedSchemes:t}}(e),o=new f.Cm;o.add(ie("uponSanitizeAttribute",((e,t)=>{if("style"!==t.attrName&&"class"!==t.attrName){if("INPUT"===e.tagName&&"checkbox"===e.attributes.getNamedItem("type")?.value){if("type"===t.attrName&&"checkbox"===t.attrValue||"disabled"===t.attrName||"checked"===t.attrName)return void(t.keepAttr=!0);t.keepAttr=!1}}else{if("SPAN"===e.tagName){if("style"===t.attrName)return void(t.keepAttr=/^(color\:(#[0-9a-fA-F]+|var\(--vscode(-[a-zA-Z]+)+\));)?(background-color\:(#[0-9a-fA-F]+|var\(--vscode(-[a-zA-Z]+)+\));)?(border-radius:[0-9]+px;)?$/.test(t.attrValue));if("class"===t.attrName)return void(t.keepAttr=/^codicon codicon-[a-z\-]+( codicon-modifier-[a-z\-]+)?$/.test(t.attrValue))}t.keepAttr=!1}}))),o.add(ie("uponSanitizeElement",((t,i)=>{if("input"===i.tagName&&("checkbox"===t.attributes.getNamedItem("type")?.value?t.setAttribute("disabled",""):e.replaceWithPlaintext||t.remove()),e.replaceWithPlaintext&&!i.allowedTags[i.tagName]&&"body"!==i.tagName&&t.parentElement){let e,s;if("#comment"===i.tagName)e=`\x3c!--${t.textContent}--\x3e`;else{const n=O.includes(i.tagName),r=t.attributes.length?" "+Array.from(t.attributes).map((e=>`${e.name}="${e.value}"`)).join(" "):"";e=`<${i.tagName}${r}>`,n||(s=``)}const n=document.createDocumentFragment(),r=t.parentElement.ownerDocument.createTextNode(e);n.appendChild(r);const o=s?t.parentElement.ownerDocument.createTextNode(s):void 0;for(;t.firstChild;)n.appendChild(t.firstChild);o&&n.appendChild(o),t.nodeType===Node.COMMENT_NODE?t.parentElement.insertBefore(n,t):t.parentElement.replaceChild(n,t)}}))),o.add(s.a4(r));try{return n.aj(t,{...i,RETURN_TRUSTED_TYPE:!0})}finally{o.dispose()}}const M=["align","autoplay","alt","checked","class","colspan","controls","data-code","data-href","disabled","draggable","height","href","loop","muted","playsinline","poster","rowspan","src","style","target","title","type","width","start"];function P(e){return"string"===typeof e?e:function(e,t){let i=e.value??"";i.length>1e5&&(i=`${i.substr(0,1e5)}\u2026`);return D({isTrusted:!1},E(i,{async:!1,renderer:t?B.value:H.value}).replace(/&(#\d+|[a-zA-Z]+);/g,(e=>F.get(e)??e))).toString()}(e)}const F=new Map([[""",'"'],[" "," "],["&","&"],["'","'"],["<","<"],[">",">"]]);function U(){const e=new v;return e.code=({text:e})=>e,e.blockquote=({text:e})=>e+"\n",e.html=e=>"",e.heading=function({tokens:e}){return this.parser.parseInline(e)+"\n"},e.hr=()=>"",e.list=function({items:e}){return e.map((e=>this.listitem(e))).join("\n")+"\n"},e.listitem=({text:e})=>e+"\n",e.paragraph=function({tokens:e}){return this.parser.parseInline(e)+"\n"},e.table=function({header:e,rows:t}){return e.map((e=>this.tablecell(e))).join(" ")+"\n"+t.map((e=>e.map((e=>this.tablecell(e))).join(" "))).join("\n")+"\n"},e.tablerow=({text:e})=>e,e.tablecell=function({tokens:e}){return this.parser.parseInline(e)},e.strong=({text:e})=>e,e.em=({text:e})=>e,e.codespan=({text:e})=>e,e.br=e=>"\n",e.del=({text:e})=>e,e.image=e=>"",e.text=({text:e})=>e,e.link=({text:e})=>e,e}const H=new m.d((e=>U())),B=new m.d((()=>{const e=U();return e.code=({text:e})=>`\n\`\`\`\n${e}\n\`\`\`\n`,e}));function W(e){let t="";return e.forEach((e=>{t+=e.raw})),t}function V(e){if(e.tokens)for(let t=e.tokens.length-1;t>=0;t--){const i=e.tokens[t];if("text"===i.type){const s=i.raw.split("\n"),n=s[s.length-1];if(n.includes("`"))return Y(e);if(n.includes("**"))return ee(e,"**");if(n.match(/\*\w/))return q(e);if(n.match(/(^|\s)__\w/))return J(e);if(n.match(/(^|\s)_\w/))return $(e);if(n.match(/(^|\s)\[.*\]\(\w*/)||z(n)&&e.tokens.slice(0,t).some((e=>"text"===e.type&&e.raw.match(/\[[^\]]*$/)))){const i=e.tokens.slice(t+1);return"link"===i[0]?.type&&"text"===i[1]?.type&&i[1].raw.match(/^ *"[^"]*$/)||n.match(/^[^"]* +"[^"]*$/)?X(e):Q(e)}if(n.match(/(^|\s)\[\w*/))return Z(e)}}}function z(e){return!!e.match(/^[^\[]*\]\([^\)]*$/)}function G(e){const t=e.items[e.items.length-1],i=t.tokens?t.tokens[t.tokens.length-1]:void 0;let s;if("text"!==i?.type||"inRawBlock"in t||(s=V(i)),!s||"paragraph"!==s.type)return;const n=W(e.items.slice(0,-1)),r=t.raw.match(/^(\s*(-|\d+\.|\*) +)/)?.[0];if(!r)return;const o=r+W(t.tokens.slice(0,-1))+s.raw,a=b(n+o)[0];return"list"===a.type?a:void 0}const j=3;function K(e){let t,i;for(t=0;t0){const e=n?i.slice(0,-1).join("\n"):t,r=!!e.match(/\|\s*$/),o=e+(r?"":"|")+`\n|${" --- |".repeat(s)}`;return b(o)}}function ie(e,t){return n.$w(e,t),(0,f.s)((()=>n.SV(e)))}},47358:(e,t,i)=>{"use strict";i.d(t,{P:()=>l,$:()=>c});var s=i(60413);const n=new WeakMap;function r(e){if(!e.parent||e.parent===e)return null;try{const t=e.location,i=e.parent.location;if("null"!==t.origin&&"null"!==i.origin&&t.origin!==i.origin)return null}catch(t){return null}return e.parent}class o{static getSameOriginWindowChain(e){let t=n.get(e);if(!t){t=[],n.set(e,t);let i,s=e;do{i=r(s),i?t.push({window:new WeakRef(s),iframeElement:s.frameElement||null}):t.push({window:new WeakRef(s),iframeElement:null}),s=i}while(s)}return t.slice(0)}static getPositionOfChildWindowRelativeToAncestorWindow(e,t){if(!t||e===t)return{top:0,left:0};let i=0,s=0;const n=this.getSameOriginWindowChain(e);for(const r of n){const e=r.window.deref();if(i+=e?.scrollY??0,s+=e?.scrollX??0,e===t)break;if(!r.iframeElement)break;const n=r.iframeElement.getBoundingClientRect();i+=n.top,s+=n.left}return{top:i,left:s}}}var a=i(98067);class l{constructor(e,t){this.timestamp=Date.now(),this.browserEvent=t,this.leftButton=0===t.button,this.middleButton=1===t.button,this.rightButton=2===t.button,this.buttons=t.buttons,this.target=t.target,this.detail=t.detail||1,"dblclick"===t.type&&(this.detail=2),this.ctrlKey=t.ctrlKey,this.shiftKey=t.shiftKey,this.altKey=t.altKey,this.metaKey=t.metaKey,"number"===typeof t.pageX?(this.posx=t.pageX,this.posy=t.pageY):(this.posx=t.clientX+this.target.ownerDocument.body.scrollLeft+this.target.ownerDocument.documentElement.scrollLeft,this.posy=t.clientY+this.target.ownerDocument.body.scrollTop+this.target.ownerDocument.documentElement.scrollTop);const i=o.getPositionOfChildWindowRelativeToAncestorWindow(e,t.view);this.posx-=i.left,this.posy-=i.top}preventDefault(){this.browserEvent.preventDefault()}stopPropagation(){this.browserEvent.stopPropagation()}}class c{constructor(e,t=0,i=0){this.browserEvent=e||null,this.target=e?e.target||e.targetNode||e.srcElement:null,this.deltaY=i,this.deltaX=t;let n=!1;if(s.H8){const e=navigator.userAgent.match(/Chrome\/(\d+)/);n=(e?parseInt(e[1]):123)<=122}if(e){const t=e,i=e,r=e.view?.devicePixelRatio||1;if("undefined"!==typeof t.wheelDeltaY)this.deltaY=n?t.wheelDeltaY/(120*r):t.wheelDeltaY/120;else if("undefined"!==typeof i.VERTICAL_AXIS&&i.axis===i.VERTICAL_AXIS)this.deltaY=-i.detail/3;else if("wheel"===e.type){const t=e;t.deltaMode===t.DOM_DELTA_LINE?s.gm&&!a.zx?this.deltaY=-e.deltaY/3:this.deltaY=-e.deltaY:this.deltaY=-e.deltaY/40}if("undefined"!==typeof t.wheelDeltaX)s.nr&&a.uF?this.deltaX=-t.wheelDeltaX/120:this.deltaX=n?t.wheelDeltaX/(120*r):t.wheelDeltaX/120;else if("undefined"!==typeof i.HORIZONTAL_AXIS&&i.axis===i.HORIZONTAL_AXIS)this.deltaX=-e.detail/3;else if("wheel"===e.type){const t=e;t.deltaMode===t.DOM_DELTA_LINE?s.gm&&!a.zx?this.deltaX=-e.deltaX/3:this.deltaX=-e.deltaX:this.deltaX=-e.deltaX/40}0===this.deltaY&&0===this.deltaX&&e.wheelDelta&&(this.deltaY=n?e.wheelDelta/(120*r):e.wheelDelta/120)}}preventDefault(){this.browserEvent?.preventDefault()}stopPropagation(){this.browserEvent?.stopPropagation()}}},5239:(e,t,i)=>{"use strict";var s;i.d(t,{p:()=>s}),function(e){const t={total:0,min:Number.MAX_VALUE,max:0},i={...t},s={...t},n={...t};let r=0;const o={keydown:0,input:0,render:0};function a(){1===o.keydown&&(performance.mark("keydown/end"),o.keydown=2)}function l(){performance.mark("input/start"),o.input=1,d()}function c(){1===o.input&&(performance.mark("input/end"),o.input=2)}function h(){1===o.render&&(performance.mark("render/end"),o.render=2)}function d(){setTimeout(u)}function u(){2===o.keydown&&2===o.input&&2===o.render&&(performance.mark("inputlatency/end"),performance.measure("keydown","keydown/start","keydown/end"),performance.measure("input","input/start","input/end"),performance.measure("render","render/start","render/end"),performance.measure("inputlatency","inputlatency/start","inputlatency/end"),g("keydown",t),g("input",i),g("render",s),g("inputlatency",n),r++,performance.clearMarks("keydown/start"),performance.clearMarks("keydown/end"),performance.clearMarks("input/start"),performance.clearMarks("input/end"),performance.clearMarks("render/start"),performance.clearMarks("render/end"),performance.clearMarks("inputlatency/start"),performance.clearMarks("inputlatency/end"),performance.clearMeasures("keydown"),performance.clearMeasures("input"),performance.clearMeasures("render"),performance.clearMeasures("inputlatency"),o.keydown=0,o.input=0,o.render=0)}function g(e,t){const i=performance.getEntriesByName(e)[0].duration;t.total+=i,t.min=Math.min(t.min,i),t.max=Math.max(t.max,i)}function p(e){return{average:e.total/r,max:e.max,min:e.min}}function m(e){e.total=0,e.min=Number.MAX_VALUE,e.max=0}e.onKeyDown=function(){u(),performance.mark("inputlatency/start"),performance.mark("keydown/start"),o.keydown=1,queueMicrotask(a)},e.onBeforeInput=l,e.onInput=function(){0===o.input&&l(),queueMicrotask(c)},e.onKeyUp=function(){u()},e.onSelectionChange=function(){u()},e.onRenderStart=function(){2===o.keydown&&2===o.input&&0===o.render&&(performance.mark("render/start"),o.render=1,queueMicrotask(h),d())},e.getAndClearMeasurements=function(){if(0===r)return;const e={keydown:p(t),input:p(i),render:p(s),total:p(n),sampleCount:r};return m(t),m(i),m(s),m(n),r=0,e}}(s||(s={}))},94106:(e,t,i)=>{"use strict";i.d(t,{c:()=>l});var s=i(8597),n=i(41234),r=i(5662);class o extends r.jG{constructor(e){super(),this._onDidChange=this._register(new n.vl),this.onDidChange=this._onDidChange.event,this._listener=()=>this._handleChange(e,!0),this._mediaQueryList=null,this._handleChange(e,!1)}_handleChange(e,t){this._mediaQueryList?.removeEventListener("change",this._listener),this._mediaQueryList=e.matchMedia(`(resolution: ${e.devicePixelRatio}dppx)`),this._mediaQueryList.addEventListener("change",this._listener),t&&this._onDidChange.fire()}}class a extends r.jG{get value(){return this._value}constructor(e){super(),this._onDidChange=this._register(new n.vl),this.onDidChange=this._onDidChange.event,this._value=this._getPixelRatio(e);const t=this._register(new o(e));this._register(t.onDidChange((()=>{this._value=this._getPixelRatio(e),this._onDidChange.fire(this._value)})))}_getPixelRatio(e){const t=document.createElement("canvas").getContext("2d");return(e.devicePixelRatio||1)/(t.webkitBackingStorePixelRatio||t.mozBackingStorePixelRatio||t.msBackingStorePixelRatio||t.oBackingStorePixelRatio||t.backingStorePixelRatio||1)}}const l=new class{constructor(){this.mapWindowIdToPixelRatioMonitor=new Map}_getOrCreatePixelRatioMonitor(e){const t=(0,s.Q2)(e);let i=this.mapWindowIdToPixelRatioMonitor.get(t);return i||(i=(0,r.lC)(new a(e)),this.mapWindowIdToPixelRatioMonitor.set(t,i),(0,r.lC)(n.Jh.once(s.Fv)((({vscodeWindowId:e})=>{e===t&&(i?.dispose(),this.mapWindowIdToPixelRatioMonitor.delete(t))})))),i}getInstance(e){return this._getOrCreatePixelRatioMonitor(e)}}},25154:(e,t,i)=>{"use strict";i.d(t,{B:()=>s,q:()=>u});var s,n=i(8597),r=i(25893),o=i(25890),a=i(58694),l=i(41234),c=i(5662),h=i(58925),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};!function(e){e.Tap="-monaco-gesturetap",e.Change="-monaco-gesturechange",e.Start="-monaco-gesturestart",e.End="-monaco-gesturesend",e.Contextmenu="-monaco-gesturecontextmenu"}(s||(s={}));class u extends c.jG{static{this.SCROLL_FRICTION=-.005}static{this.HOLD_DELAY=700}static{this.CLEAR_TAP_COUNT_TIME=400}constructor(){super(),this.dispatched=!1,this.targets=new h.w,this.ignoreTargets=new h.w,this.activeTouches={},this.handle=null,this._lastSetTapCountTime=0,this._register(l.Jh.runAndSubscribe(n.Iv,(({window:e,disposables:t})=>{t.add(n.ko(e.document,"touchstart",(e=>this.onTouchStart(e)),{passive:!1})),t.add(n.ko(e.document,"touchend",(t=>this.onTouchEnd(e,t)))),t.add(n.ko(e.document,"touchmove",(e=>this.onTouchMove(e)),{passive:!1}))}),{window:r.G,disposables:this._store}))}static addTarget(e){if(!u.isTouchDevice())return c.jG.None;u.INSTANCE||(u.INSTANCE=(0,c.lC)(new u));const t=u.INSTANCE.targets.push(e);return(0,c.s)(t)}static ignoreTarget(e){if(!u.isTouchDevice())return c.jG.None;u.INSTANCE||(u.INSTANCE=(0,c.lC)(new u));const t=u.INSTANCE.ignoreTargets.push(e);return(0,c.s)(t)}static isTouchDevice(){return"ontouchstart"in r.G||navigator.maxTouchPoints>0}dispose(){this.handle&&(this.handle.dispose(),this.handle=null),super.dispose()}onTouchStart(e){const t=Date.now();this.handle&&(this.handle.dispose(),this.handle=null);for(let i=0,n=e.targetTouches.length;i=u.HOLD_DELAY&&Math.abs(l.initialPageX-o.RT(l.rollingPageX))<30&&Math.abs(l.initialPageY-o.RT(l.rollingPageY))<30){const e=this.newGestureEvent(s.Contextmenu,l.initialTarget);e.pageX=o.RT(l.rollingPageX),e.pageY=o.RT(l.rollingPageY),this.dispatchEvent(e)}else if(1===n){const t=o.RT(l.rollingPageX),s=o.RT(l.rollingPageY),n=o.RT(l.rollingTimestamps)-l.rollingTimestamps[0],r=t-l.rollingPageX[0],a=s-l.rollingPageY[0],c=[...this.targets].filter((e=>l.initialTarget instanceof Node&&e.contains(l.initialTarget)));this.inertia(e,c,i,Math.abs(r)/n,r>0?1:-1,t,Math.abs(a)/n,a>0?1:-1,s)}this.dispatchEvent(this.newGestureEvent(s.End,l.initialTarget)),delete this.activeTouches[a.identifier]}this.dispatched&&(t.preventDefault(),t.stopPropagation(),this.dispatched=!1)}newGestureEvent(e,t){const i=document.createEvent("CustomEvent");return i.initEvent(e,!1,!0),i.initialTarget=t,i.tapCount=0,i}dispatchEvent(e){if(e.type===s.Tap){const t=(new Date).getTime();let i=0;i=t-this._lastSetTapCountTime>u.CLEAR_TAP_COUNT_TIME?1:2,this._lastSetTapCountTime=t,e.tapCount=i}else e.type!==s.Change&&e.type!==s.Contextmenu||(this._lastSetTapCountTime=0);if(e.initialTarget instanceof Node){for(const i of this.ignoreTargets)if(i.contains(e.initialTarget))return;const t=[];for(const i of this.targets)if(i.contains(e.initialTarget)){let s=0,n=e.initialTarget;for(;n&&n!==i;)s++,n=n.parentElement;t.push([s,i])}t.sort(((e,t)=>e[0]-t[0]));for(const[i,s]of t)s.dispatchEvent(e),this.dispatched=!0}}inertia(e,t,i,r,o,a,l,c,h){this.handle=n.PG(e,(()=>{const n=Date.now(),d=n-i;let g=0,p=0,m=!0;r+=u.SCROLL_FRICTION*d,l+=u.SCROLL_FRICTION*d,r>0&&(m=!1,g=o*r*d),l>0&&(m=!1,p=c*l*d);const f=this.newGestureEvent(s.Change);f.translationX=g,f.translationY=p,t.forEach((e=>e.dispatchEvent(f))),m||this.inertia(e,t,n,r,o,a+g,l,c,h+p)}))}onTouchMove(e){const t=Date.now();for(let i=0,n=e.changedTouches.length;i3&&(r.rollingPageX.shift(),r.rollingPageY.shift(),r.rollingTimestamps.shift()),r.rollingPageX.push(n.pageX),r.rollingPageY.push(n.pageY),r.rollingTimestamps.push(t)}this.dispatched&&(e.preventDefault(),e.stopPropagation(),this.dispatched=!1)}}d([a.B],u,"isTouchDevice",null)},80789:(e,t,i)=>{"use strict";i.d(t,{H:()=>n});var s=i(64383);function n(e,t){const i=globalThis.MonacoEnvironment;if(i?.createTrustedTypesPolicy)try{return i.createTrustedTypesPolicy(e,t)}catch(n){return void(0,s.dz)(n)}try{return globalThis.trustedTypes?.createPolicy(e,t)}catch(n){return void(0,s.dz)(n)}}},5646:(e,t,i)=>{"use strict";i.d(t,{Z4:()=>k,EH:()=>x,XF:()=>A});var s=i(60413),n=i(42731),r=i(8597),o=i(25154),a=i(42904),l=i(56245),c=i(72962),h=i(68214),d=i(48196),u=i(93090),g=i(25890),p=i(41234),m=i(24939),f=i(5662),_=i(98067),v=i(78209);const C=r.$,b="selectOption.entry.template";class E{get templateId(){return b}renderTemplate(e){const t=Object.create(null);return t.root=e,t.text=r.BC(e,C(".option-text")),t.detail=r.BC(e,C(".option-detail")),t.decoratorRight=r.BC(e,C(".option-decorator-right")),t}renderElement(e,t,i){const s=i,n=e.text,r=e.detail,o=e.decoratorRight,a=e.isDisabled;s.text.textContent=n,s.detail.textContent=r||"",s.decoratorRight.innerText=o||"",a?s.root.classList.add("option-disabled"):s.root.classList.remove("option-disabled")}disposeTemplate(e){}}class S extends f.jG{static{this.DEFAULT_DROPDOWN_MINIMUM_BOTTOM_MARGIN=32}static{this.DEFAULT_DROPDOWN_MINIMUM_TOP_MARGIN=2}static{this.DEFAULT_MINIMUM_VISIBLE_OPTIONS=3}constructor(e,t,i,s,n){super(),this.options=[],this._currentSelection=0,this._hasDetails=!1,this._skipLayout=!1,this._sticky=!1,this._isVisible=!1,this.styles=s,this.selectBoxOptions=n||Object.create(null),"number"!==typeof this.selectBoxOptions.minBottomMargin?this.selectBoxOptions.minBottomMargin=S.DEFAULT_DROPDOWN_MINIMUM_BOTTOM_MARGIN:this.selectBoxOptions.minBottomMargin<0&&(this.selectBoxOptions.minBottomMargin=0),this.selectElement=document.createElement("select"),this.selectElement.className="monaco-select-box monaco-select-box-dropdown-padding","string"===typeof this.selectBoxOptions.ariaLabel&&this.selectElement.setAttribute("aria-label",this.selectBoxOptions.ariaLabel),"string"===typeof this.selectBoxOptions.ariaDescription&&this.selectElement.setAttribute("aria-description",this.selectBoxOptions.ariaDescription),this._onDidSelect=new p.vl,this._register(this._onDidSelect),this.registerListeners(),this.constructSelectDropDown(i),this.selected=t||0,e&&this.setOptions(e,t),this.initStyleSheet()}setTitle(e){!this._hover&&e?this._hover=this._register((0,d.i)().setupManagedHover((0,a.nZ)("mouse"),this.selectElement,e)):this._hover&&this._hover.update(e)}getHeight(){return 22}getTemplateId(){return b}constructSelectDropDown(e){this.contextViewProvider=e,this.selectDropDownContainer=r.$(".monaco-select-box-dropdown-container"),this.selectDropDownContainer.classList.add("monaco-select-box-dropdown-padding"),this.selectionDetailsPane=r.BC(this.selectDropDownContainer,C(".select-box-details-pane"));const t=r.BC(this.selectDropDownContainer,C(".select-box-dropdown-container-width-control")),i=r.BC(t,C(".width-control-div"));this.widthControlElement=document.createElement("span"),this.widthControlElement.className="option-text-width-control",r.BC(i,this.widthControlElement),this._dropDownPosition=0,this.styleElement=r.li(this.selectDropDownContainer),this.selectDropDownContainer.setAttribute("draggable","true"),this._register(r.ko(this.selectDropDownContainer,r.Bx.DRAG_START,(e=>{r.fs.stop(e,!0)})))}registerListeners(){let e;this._register(r.b2(this.selectElement,"change",(e=>{this.selected=e.target.selectedIndex,this._onDidSelect.fire({index:e.target.selectedIndex,selected:e.target.value}),this.options[this.selected]&&this.options[this.selected].text&&this.setTitle(this.options[this.selected].text)}))),this._register(r.ko(this.selectElement,r.Bx.CLICK,(e=>{r.fs.stop(e),this._isVisible?this.hideSelectDropDown(!0):this.showSelectDropDown()}))),this._register(r.ko(this.selectElement,r.Bx.MOUSE_DOWN,(e=>{r.fs.stop(e)}))),this._register(r.ko(this.selectElement,"touchstart",(t=>{e=this._isVisible}))),this._register(r.ko(this.selectElement,"touchend",(t=>{r.fs.stop(t),e?this.hideSelectDropDown(!0):this.showSelectDropDown()}))),this._register(r.ko(this.selectElement,r.Bx.KEY_DOWN,(e=>{const t=new c.Z(e);let i=!1;_.zx?18!==t.keyCode&&16!==t.keyCode&&10!==t.keyCode&&3!==t.keyCode||(i=!0):(18===t.keyCode&&t.altKey||16===t.keyCode&&t.altKey||10===t.keyCode||3===t.keyCode)&&(i=!0),i&&(this.showSelectDropDown(),r.fs.stop(e,!0))})))}get onDidSelect(){return this._onDidSelect.event}setOptions(e,t){g.aI(this.options,e)||(this.options=e,this.selectElement.options.length=0,this._hasDetails=!1,this._cachedMaxDetailsHeight=void 0,this.options.forEach(((e,t)=>{this.selectElement.add(this.createOption(e.text,t,e.isDisabled)),"string"===typeof e.description&&(this._hasDetails=!0)}))),void 0!==t&&(this.select(t),this._currentSelection=this.selected)}setOptionsList(){this.selectList?.splice(0,this.selectList.length,this.options)}select(e){e>=0&&ethis.options.length-1?this.select(this.options.length-1):this.selected<0&&(this.selected=0),this.selectElement.selectedIndex=this.selected,this.options[this.selected]&&this.options[this.selected].text&&this.setTitle(this.options[this.selected].text)}focus(){this.selectElement&&(this.selectElement.tabIndex=0,this.selectElement.focus())}blur(){this.selectElement&&(this.selectElement.tabIndex=-1,this.selectElement.blur())}setFocusable(e){this.selectElement.tabIndex=e?0:-1}render(e){this.container=e,e.classList.add("select-container"),e.appendChild(this.selectElement),this.styleSelectElement()}initStyleSheet(){const e=[];this.styles.listFocusBackground&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row.focused { background-color: ${this.styles.listFocusBackground} !important; }`),this.styles.listFocusForeground&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row.focused { color: ${this.styles.listFocusForeground} !important; }`),this.styles.decoratorRightForeground&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row:not(.focused) .option-decorator-right { color: ${this.styles.decoratorRightForeground}; }`),this.styles.selectBackground&&this.styles.selectBorder&&this.styles.selectBorder!==this.styles.selectBackground?(e.push(`.monaco-select-box-dropdown-container { border: 1px solid ${this.styles.selectBorder} } `),e.push(`.monaco-select-box-dropdown-container > .select-box-details-pane.border-top { border-top: 1px solid ${this.styles.selectBorder} } `),e.push(`.monaco-select-box-dropdown-container > .select-box-details-pane.border-bottom { border-bottom: 1px solid ${this.styles.selectBorder} } `)):this.styles.selectListBorder&&(e.push(`.monaco-select-box-dropdown-container > .select-box-details-pane.border-top { border-top: 1px solid ${this.styles.selectListBorder} } `),e.push(`.monaco-select-box-dropdown-container > .select-box-details-pane.border-bottom { border-bottom: 1px solid ${this.styles.selectListBorder} } `)),this.styles.listHoverForeground&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row:not(.option-disabled):not(.focused):hover { color: ${this.styles.listHoverForeground} !important; }`),this.styles.listHoverBackground&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row:not(.option-disabled):not(.focused):hover { background-color: ${this.styles.listHoverBackground} !important; }`),this.styles.listFocusOutline&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row.focused { outline: 1.6px dotted ${this.styles.listFocusOutline} !important; outline-offset: -1.6px !important; }`),this.styles.listHoverOutline&&e.push(`.monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row:not(.option-disabled):not(.focused):hover { outline: 1.6px dashed ${this.styles.listHoverOutline} !important; outline-offset: -1.6px !important; }`),e.push(".monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row.option-disabled.focused { background-color: transparent !important; color: inherit !important; outline: none !important; }"),e.push(".monaco-select-box-dropdown-container > .select-box-dropdown-list-container .monaco-list .monaco-list-row.option-disabled:hover { background-color: transparent !important; color: inherit !important; outline: none !important; }"),this.styleElement.textContent=e.join("\n")}styleSelectElement(){const e=this.styles.selectBackground??"",t=this.styles.selectForeground??"",i=this.styles.selectBorder??"";this.selectElement.style.backgroundColor=e,this.selectElement.style.color=t,this.selectElement.style.borderColor=i}styleList(){const e=this.styles.selectBackground??"",t=r.gI(this.styles.selectListBackground,e);this.selectDropDownListContainer.style.backgroundColor=t,this.selectionDetailsPane.style.backgroundColor=t;const i=this.styles.focusBorder??"";this.selectDropDownContainer.style.outlineColor=i,this.selectDropDownContainer.style.outlineOffset="-1px",this.selectList.style(this.styles)}createOption(e,t,i){const s=document.createElement("option");return s.value=e,s.text=e,s.disabled=!!i,s}showSelectDropDown(){this.selectionDetailsPane.innerText="",this.contextViewProvider&&!this._isVisible&&(this.createSelectList(this.selectDropDownContainer),this.setOptionsList(),this.contextViewProvider.showContextView({getAnchor:()=>this.selectElement,render:e=>this.renderSelectDropDown(e,!0),layout:()=>{this.layoutSelectDropDown()},onHide:()=>{this.selectDropDownContainer.classList.remove("visible"),this.selectElement.classList.remove("synthetic-focus")},anchorPosition:this._dropDownPosition},this.selectBoxOptions.optionsAsChildren?this.container:void 0),this._isVisible=!0,this.hideSelectDropDown(!1),this.contextViewProvider.showContextView({getAnchor:()=>this.selectElement,render:e=>this.renderSelectDropDown(e),layout:()=>this.layoutSelectDropDown(),onHide:()=>{this.selectDropDownContainer.classList.remove("visible"),this.selectElement.classList.remove("synthetic-focus")},anchorPosition:this._dropDownPosition},this.selectBoxOptions.optionsAsChildren?this.container:void 0),this._currentSelection=this.selected,this._isVisible=!0,this.selectElement.setAttribute("aria-expanded","true"))}hideSelectDropDown(e){this.contextViewProvider&&this._isVisible&&(this._isVisible=!1,this.selectElement.setAttribute("aria-expanded","false"),e&&this.selectElement.focus(),this.contextViewProvider.hideContextView())}renderSelectDropDown(e,t){return e.appendChild(this.selectDropDownContainer),this.layoutSelectDropDown(t),{dispose:()=>{this.selectDropDownContainer.remove()}}}measureMaxDetailsHeight(){let e=0;return this.options.forEach(((t,i)=>{this.updateDetail(i),this.selectionDetailsPane.offsetHeight>e&&(e=this.selectionDetailsPane.offsetHeight)})),e}layoutSelectDropDown(e){if(this._skipLayout)return!1;if(this.selectList){this.selectDropDownContainer.classList.add("visible");const t=r.zk(this.selectElement),i=r.BK(this.selectElement),s=r.zk(this.selectElement).getComputedStyle(this.selectElement),n=parseFloat(s.getPropertyValue("--dropdown-padding-top"))+parseFloat(s.getPropertyValue("--dropdown-padding-bottom")),o=t.innerHeight-i.top-i.height-(this.selectBoxOptions.minBottomMargin||0),a=i.top-S.DEFAULT_DROPDOWN_MINIMUM_TOP_MARGIN,l=this.selectElement.offsetWidth,c=this.setWidthControlElement(this.widthControlElement),h=Math.max(c,Math.round(l)).toString()+"px";this.selectDropDownContainer.style.width=h,this.selectList.getHTMLElement().style.height="",this.selectList.layout();let d=this.selectList.contentHeight;this._hasDetails&&void 0===this._cachedMaxDetailsHeight&&(this._cachedMaxDetailsHeight=this.measureMaxDetailsHeight());const u=this._hasDetails?this._cachedMaxDetailsHeight:0,g=d+n+u,p=Math.floor((o-n-u)/this.getHeight()),m=Math.floor((a-n-u)/this.getHeight());if(e)return!(i.top+i.height>t.innerHeight-22||i.topp&&this.options.length>p?(this._dropDownPosition=1,this.selectDropDownListContainer.remove(),this.selectionDetailsPane.remove(),this.selectDropDownContainer.appendChild(this.selectionDetailsPane),this.selectDropDownContainer.appendChild(this.selectDropDownListContainer),this.selectionDetailsPane.classList.remove("border-top"),this.selectionDetailsPane.classList.add("border-bottom")):(this._dropDownPosition=0,this.selectDropDownListContainer.remove(),this.selectionDetailsPane.remove(),this.selectDropDownContainer.appendChild(this.selectDropDownListContainer),this.selectDropDownContainer.appendChild(this.selectionDetailsPane),this.selectionDetailsPane.classList.remove("border-bottom"),this.selectionDetailsPane.classList.add("border-top")),!0);if(i.top+i.height>t.innerHeight-22||i.topo&&(d=p*this.getHeight())}else g>a&&(d=m*this.getHeight());return this.selectList.layout(d),this.selectList.domFocus(),this.selectList.length>0&&(this.selectList.setFocus([this.selected||0]),this.selectList.reveal(this.selectList.getFocus()[0]||0)),this._hasDetails?(this.selectList.getHTMLElement().style.height=d+n+"px",this.selectDropDownContainer.style.height=""):this.selectDropDownContainer.style.height=d+n+"px",this.updateDetail(this.selected),this.selectDropDownContainer.style.width=h,this.selectDropDownListContainer.setAttribute("tabindex","0"),this.selectElement.classList.add("synthetic-focus"),this.selectDropDownContainer.classList.add("synthetic-focus"),!0}return!1}setWidthControlElement(e){let t=0;if(e){let i=0,s=0;this.options.forEach(((e,t)=>{const n=e.detail?e.detail.length:0,r=e.decoratorRight?e.decoratorRight.length:0,o=e.text.length+n+r;o>s&&(i=t,s=o)})),e.textContent=this.options[i].text+(this.options[i].decoratorRight?this.options[i].decoratorRight+" ":""),t=r.Tr(e)}return t}createSelectList(e){if(this.selectList)return;this.selectDropDownListContainer=r.BC(e,C(".select-box-dropdown-list-container")),this.listRenderer=new E,this.selectList=this._register(new u.B8("SelectBoxCustom",this.selectDropDownListContainer,this,[this.listRenderer],{useShadows:!1,verticalScrollMode:3,keyboardSupport:!1,mouseSupport:!1,accessibilityProvider:{getAriaLabel:e=>{let t=e.text;return e.detail&&(t+=`. ${e.detail}`),e.decoratorRight&&(t+=`. ${e.decoratorRight}`),e.description&&(t+=`. ${e.description}`),t},getWidgetAriaLabel:()=>(0,v.kg)({key:"selectBox",comment:["Behave like native select dropdown element."]},"Select Box"),getRole:()=>_.zx?"":"option",getWidgetRole:()=>"listbox"}})),this.selectBoxOptions.ariaLabel&&(this.selectList.ariaLabel=this.selectBoxOptions.ariaLabel);const t=this._register(new l.f(this.selectDropDownListContainer,"keydown")),i=p.Jh.chain(t.event,(e=>e.filter((()=>this.selectList.length>0)).map((e=>new c.Z(e)))));this._register(p.Jh.chain(i,(e=>e.filter((e=>3===e.keyCode))))(this.onEnter,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>2===e.keyCode))))(this.onEnter,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>9===e.keyCode))))(this.onEscape,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>16===e.keyCode))))(this.onUpArrow,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>18===e.keyCode))))(this.onDownArrow,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>12===e.keyCode))))(this.onPageDown,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>11===e.keyCode))))(this.onPageUp,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>14===e.keyCode))))(this.onHome,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>13===e.keyCode))))(this.onEnd,this)),this._register(p.Jh.chain(i,(e=>e.filter((e=>e.keyCode>=21&&e.keyCode<=56||e.keyCode>=85&&e.keyCode<=113))))(this.onCharacter,this)),this._register(r.ko(this.selectList.getHTMLElement(),r.Bx.POINTER_UP,(e=>this.onPointerUp(e)))),this._register(this.selectList.onMouseOver((e=>"undefined"!==typeof e.index&&this.selectList.setFocus([e.index])))),this._register(this.selectList.onDidChangeFocus((e=>this.onListFocus(e)))),this._register(r.ko(this.selectDropDownContainer,r.Bx.FOCUS_OUT,(e=>{this._isVisible&&!r.QX(e.relatedTarget,this.selectDropDownContainer)&&this.onListBlur()}))),this.selectList.getHTMLElement().setAttribute("aria-label",this.selectBoxOptions.ariaLabel||""),this.selectList.getHTMLElement().setAttribute("aria-expanded","true"),this.styleList()}onPointerUp(e){if(!this.selectList.length)return;r.fs.stop(e);const t=e.target;if(!t)return;if(t.classList.contains("slider"))return;const i=t.closest(".monaco-list-row");if(!i)return;const s=Number(i.getAttribute("data-index")),n=i.classList.contains("option-disabled");s>=0&&s{for(let t=0;tthis.selected+2)this.selected+=2;else{if(t)return;this.selected++}this.select(this.selected),this.selectList.setFocus([this.selected]),this.selectList.reveal(this.selectList.getFocus()[0])}}onUpArrow(e){if(this.selected>0){r.fs.stop(e,!0);this.options[this.selected-1].isDisabled&&this.selected>1?this.selected-=2:this.selected--,this.select(this.selected),this.selectList.setFocus([this.selected]),this.selectList.reveal(this.selectList.getFocus()[0])}}onPageUp(e){r.fs.stop(e),this.selectList.focusPreviousPage(),setTimeout((()=>{this.selected=this.selectList.getFocus()[0],this.options[this.selected].isDisabled&&this.selected{this.selected=this.selectList.getFocus()[0],this.options[this.selected].isDisabled&&this.selected>0&&(this.selected--,this.selectList.setFocus([this.selected])),this.selectList.reveal(this.selected),this.select(this.selected)}),1)}onHome(e){r.fs.stop(e),this.options.length<2||(this.selected=0,this.options[this.selected].isDisabled&&this.selected>1&&this.selected++,this.selectList.setFocus([this.selected]),this.selectList.reveal(this.selected),this.select(this.selected))}onEnd(e){r.fs.stop(e),this.options.length<2||(this.selected=this.options.length-1,this.options[this.selected].isDisabled&&this.selected>1&&this.selected--,this.selectList.setFocus([this.selected]),this.selectList.reveal(this.selected),this.select(this.selected))}onCharacter(e){const t=m.YM.toString(e.keyCode);let i=-1;for(let s=0;s{this._register(r.ko(this.selectElement,e,(e=>{this.selectElement.focus()})))})),this._register(r.b2(this.selectElement,"click",(e=>{r.fs.stop(e,!0)}))),this._register(r.b2(this.selectElement,"change",(e=>{this.selectElement.title=e.target.value,this._onDidSelect.fire({index:e.target.selectedIndex,selected:e.target.value})}))),this._register(r.b2(this.selectElement,"keydown",(e=>{let t=!1;_.zx?18!==e.keyCode&&16!==e.keyCode&&10!==e.keyCode||(t=!0):(18===e.keyCode&&e.altKey||10===e.keyCode||3===e.keyCode)&&(t=!0),t&&e.stopPropagation()})))}get onDidSelect(){return this._onDidSelect.event}setOptions(e,t){this.options&&g.aI(this.options,e)||(this.options=e,this.selectElement.options.length=0,this.options.forEach(((e,t)=>{this.selectElement.add(this.createOption(e.text,t,e.isDisabled))}))),void 0!==t&&this.select(t)}select(e){0===this.options.length?this.selected=0:e>=0&&ethis.options.length-1?this.select(this.options.length-1):this.selected<0&&(this.selected=0),this.selectElement.selectedIndex=this.selected,this.selected{this.element&&this.handleActionChangeEvent(e)})))}handleActionChangeEvent(e){void 0!==e.enabled&&this.updateEnabled(),void 0!==e.checked&&this.updateChecked(),void 0!==e.class&&this.updateClass(),void 0!==e.label&&(this.updateLabel(),this.updateTooltip()),void 0!==e.tooltip&&this.updateTooltip()}get actionRunner(){return this._actionRunner||(this._actionRunner=this._register(new R.LN)),this._actionRunner}set actionRunner(e){this._actionRunner=e}isEnabled(){return this._action.enabled}setActionContext(e){this._context=e}render(e){const t=this.element=e;this._register(o.q.addTarget(e));const i=this.options&&this.options.draggable;i&&(e.draggable=!0,s.gm&&this._register((0,r.ko)(e,r.Bx.DRAG_START,(e=>e.dataTransfer?.setData(n.t.TEXT,this._action.label))))),this._register((0,r.ko)(t,o.B.Tap,(e=>this.onClick(e,!0)))),this._register((0,r.ko)(t,r.Bx.MOUSE_DOWN,(e=>{i||r.fs.stop(e,!0),this._action.enabled&&0===e.button&&t.classList.add("active")}))),_.zx&&this._register((0,r.ko)(t,r.Bx.CONTEXT_MENU,(e=>{0===e.button&&!0===e.ctrlKey&&this.onClick(e)}))),this._register((0,r.ko)(t,r.Bx.CLICK,(e=>{r.fs.stop(e,!0),this.options&&this.options.isMenu||this.onClick(e)}))),this._register((0,r.ko)(t,r.Bx.DBLCLICK,(e=>{r.fs.stop(e,!0)}))),[r.Bx.MOUSE_UP,r.Bx.MOUSE_OUT].forEach((e=>{this._register((0,r.ko)(t,e,(e=>{r.fs.stop(e),t.classList.remove("active")})))}))}onClick(e,t=!1){r.fs.stop(e,!0);const i=T.z(this._context)?this.options?.useEventAsContext?e:{preserveFocus:t}:this._context;this.actionRunner.run(this._action,i)}focus(){this.element&&(this.element.tabIndex=0,this.element.focus(),this.element.classList.add("focused"))}blur(){this.element&&(this.element.blur(),this.element.tabIndex=-1,this.element.classList.remove("focused"))}setFocusable(e){this.element&&(this.element.tabIndex=e?0:-1)}get trapsArrowNavigation(){return!1}updateEnabled(){}updateLabel(){}getClass(){return this.action.class}getTooltip(){return this.action.tooltip}updateTooltip(){if(!this.element)return;const e=this.getTooltip()??"";if(this.updateAriaLabel(),this.options.hoverDelegate?.showNativeHover)this.element.title=e;else if(this.customHover||""===e)this.customHover&&this.customHover.update(e);else{const t=this.options.hoverDelegate??(0,a.nZ)("element");this.customHover=this._store.add((0,d.i)().setupManagedHover(t,this.element,e))}}updateAriaLabel(){if(this.element){const e=this.getTooltip()??"";this.element.setAttribute("aria-label",e)}}updateClass(){}updateChecked(){}dispose(){this.element&&(this.element.remove(),this.element=void 0),this._context=void 0,super.dispose()}}class k extends x{constructor(e,t,i){super(e,t,i),this.options=i,this.options.icon=void 0!==i.icon&&i.icon,this.options.label=void 0===i.label||i.label,this.cssClass=""}render(e){super.render(e),T.j(this.element);const t=document.createElement("a");if(t.classList.add("action-label"),t.setAttribute("role",this.getDefaultAriaRole()),this.label=t,this.element.appendChild(t),this.options.label&&this.options.keybinding){const e=document.createElement("span");e.classList.add("keybinding"),e.textContent=this.options.keybinding,this.element.appendChild(e)}this.updateClass(),this.updateLabel(),this.updateTooltip(),this.updateEnabled(),this.updateChecked()}getDefaultAriaRole(){return this._action.id===R.wv.ID?"presentation":this.options.isMenu?"menuitem":this.options.isTabList?"tab":"button"}focus(){this.label&&(this.label.tabIndex=0,this.label.focus())}blur(){this.label&&(this.label.tabIndex=-1)}setFocusable(e){this.label&&(this.label.tabIndex=e?0:-1)}updateLabel(){this.options.label&&this.label&&(this.label.textContent=this.action.label)}getTooltip(){let e=null;return this.action.tooltip?e=this.action.tooltip:!this.options.label&&this.action.label&&this.options.icon&&(e=this.action.label,this.options.keybinding&&(e=v.kg({key:"titleLabel",comment:["action title","action keybinding"]},"{0} ({1})",e,this.options.keybinding))),e??void 0}updateClass(){this.cssClass&&this.label&&this.label.classList.remove(...this.cssClass.split(" ")),this.options.icon?(this.cssClass=this.getClass(),this.label&&(this.label.classList.add("codicon"),this.cssClass&&this.label.classList.add(...this.cssClass.split(" "))),this.updateEnabled()):this.label?.classList.remove("codicon")}updateEnabled(){this.action.enabled?(this.label&&(this.label.removeAttribute("aria-disabled"),this.label.classList.remove("disabled")),this.element?.classList.remove("disabled")):(this.label&&(this.label.setAttribute("aria-disabled","true"),this.label.classList.add("disabled")),this.element?.classList.add("disabled"))}updateAriaLabel(){if(this.label){const e=this.getTooltip()??"";this.label.setAttribute("aria-label",e)}}updateChecked(){this.label&&(void 0!==this.action.checked?(this.label.classList.toggle("checked",this.action.checked),this.options.isTabList?this.label.setAttribute("aria-selected",this.action.checked?"true":"false"):(this.label.setAttribute("aria-checked",this.action.checked?"true":"false"),this.label.setAttribute("role","checkbox"))):(this.label.classList.remove("checked"),this.label.removeAttribute(this.options.isTabList?"aria-selected":"aria-checked"),this.label.setAttribute("role",this.getDefaultAriaRole())))}}class A extends x{constructor(e,t,i,s,n,r,o){super(e,t),this.selectBox=new L(i,s,n,r,o),this.selectBox.setFocusable(!1),this._register(this.selectBox),this.registerListeners()}select(e){this.selectBox.select(e)}registerListeners(){this._register(this.selectBox.onDidSelect((e=>this.runAction(e.selected,e.index))))}runAction(e,t){this.actionRunner.run(this._action,this.getActionContext(e,t))}getActionContext(e,t){return e}setFocusable(e){this.selectBox.setFocusable(e)}focus(){this.selectBox?.focus()}blur(){this.selectBox?.blur()}render(e){this.selectBox.render(e)}}},11799:(e,t,i)=>{"use strict";i.d(t,{E:()=>d});var s=i(8597),n=i(72962),r=i(5646),o=i(42904),a=i(36921),l=i(41234),c=i(5662),h=i(631);i(62469);class d extends c.jG{constructor(e,t={}){let i,h;switch(super(),this._actionRunnerDisposables=this._register(new c.Cm),this.viewItemDisposables=this._register(new c.$w),this.triggerKeyDown=!1,this.focusable=!0,this._onDidBlur=this._register(new l.vl),this.onDidBlur=this._onDidBlur.event,this._onDidCancel=this._register(new l.vl({onWillAddFirstListener:()=>this.cancelHasListener=!0})),this.onDidCancel=this._onDidCancel.event,this.cancelHasListener=!1,this._onDidRun=this._register(new l.vl),this.onDidRun=this._onDidRun.event,this._onWillRun=this._register(new l.vl),this.onWillRun=this._onWillRun.event,this.options=t,this._context=t.context??null,this._orientation=this.options.orientation??0,this._triggerKeys={keyDown:this.options.triggerKeys?.keyDown??!1,keys:this.options.triggerKeys?.keys??[3,10]},this._hoverDelegate=t.hoverDelegate??this._register((0,o.bW)()),this.options.actionRunner?this._actionRunner=this.options.actionRunner:(this._actionRunner=new a.LN,this._actionRunnerDisposables.add(this._actionRunner)),this._actionRunnerDisposables.add(this._actionRunner.onDidRun((e=>this._onDidRun.fire(e)))),this._actionRunnerDisposables.add(this._actionRunner.onWillRun((e=>this._onWillRun.fire(e)))),this.viewItems=[],this.focusedItem=void 0,this.domNode=document.createElement("div"),this.domNode.className="monaco-action-bar",this._orientation){case 0:i=[15],h=[17];break;case 1:i=[16],h=[18],this.domNode.className+=" vertical"}this._register(s.ko(this.domNode,s.Bx.KEY_DOWN,(e=>{const t=new n.Z(e);let s=!0;const o="number"===typeof this.focusedItem?this.viewItems[this.focusedItem]:void 0;i&&(t.equals(i[0])||t.equals(i[1]))?s=this.focusPrevious():h&&(t.equals(h[0])||t.equals(h[1]))?s=this.focusNext():t.equals(9)&&this.cancelHasListener?this._onDidCancel.fire():t.equals(14)?s=this.focusFirst():t.equals(13)?s=this.focusLast():t.equals(2)&&o instanceof r.EH&&o.trapsArrowNavigation?s=this.focusNext(void 0,!0):this.isTriggerKeyEvent(t)?this._triggerKeys.keyDown?this.doTrigger(t):this.triggerKeyDown=!0:s=!1,s&&(t.preventDefault(),t.stopPropagation())}))),this._register(s.ko(this.domNode,s.Bx.KEY_UP,(e=>{const t=new n.Z(e);this.isTriggerKeyEvent(t)?(!this._triggerKeys.keyDown&&this.triggerKeyDown&&(this.triggerKeyDown=!1,this.doTrigger(t)),t.preventDefault(),t.stopPropagation()):(t.equals(2)||t.equals(1026)||t.equals(16)||t.equals(18)||t.equals(15)||t.equals(17))&&this.updateFocusedItem()}))),this.focusTracker=this._register(s.w5(this.domNode)),this._register(this.focusTracker.onDidBlur((()=>{s.bq()!==this.domNode&&s.QX(s.bq(),this.domNode)||(this._onDidBlur.fire(),this.previouslyFocusedItem=this.focusedItem,this.focusedItem=void 0,this.triggerKeyDown=!1)}))),this._register(this.focusTracker.onDidFocus((()=>this.updateFocusedItem()))),this.actionsList=document.createElement("ul"),this.actionsList.className="actions-container",this.options.highlightToggledItems&&this.actionsList.classList.add("highlight-toggled"),this.actionsList.setAttribute("role",this.options.ariaRole||"toolbar"),this.options.ariaLabel&&this.actionsList.setAttribute("aria-label",this.options.ariaLabel),this.domNode.appendChild(this.actionsList),e.appendChild(this.domNode)}refreshRole(){this.length()>=1?this.actionsList.setAttribute("role",this.options.ariaRole||"toolbar"):this.actionsList.setAttribute("role","presentation")}setFocusable(e){if(this.focusable=e,this.focusable){const e=this.viewItems.find((e=>e instanceof r.EH&&e.isEnabled()));e instanceof r.EH&&e.setFocusable(!0)}else this.viewItems.forEach((e=>{e instanceof r.EH&&e.setFocusable(!1)}))}isTriggerKeyEvent(e){let t=!1;return this._triggerKeys.keys.forEach((i=>{t=t||e.equals(i)})),t}updateFocusedItem(){for(let e=0;et.setActionContext(e)))}get actionRunner(){return this._actionRunner}set actionRunner(e){this._actionRunner=e,this._actionRunnerDisposables.clear(),this._actionRunnerDisposables.add(this._actionRunner.onDidRun((e=>this._onDidRun.fire(e)))),this._actionRunnerDisposables.add(this._actionRunner.onWillRun((e=>this._onWillRun.fire(e)))),this.viewItems.forEach((t=>t.actionRunner=e))}getContainer(){return this.domNode}getAction(e){if("number"===typeof e)return this.viewItems[e]?.action;if(s.sb(e)){for(;e.parentElement!==this.actionsList;){if(!e.parentElement)return;e=e.parentElement}for(let t=0;t{const i=document.createElement("li");let o;i.className="action-item",i.setAttribute("role","presentation");const a={hoverDelegate:this._hoverDelegate,...t,isTabList:"tablist"===this.options.ariaRole};this.options.actionViewItemProvider&&(o=this.options.actionViewItemProvider(e,a)),o||(o=new r.Z4(this.context,e,a)),this.options.allowContextMenu||this.viewItemDisposables.set(o,s.ko(i,s.Bx.CONTEXT_MENU,(e=>{s.fs.stop(e,!0)}))),o.actionRunner=this._actionRunner,o.setActionContext(this.context),o.render(i),this.focusable&&o instanceof r.EH&&0===this.viewItems.length&&o.setFocusable(!0),null===n||n<0||n>=this.actionsList.children.length?(this.actionsList.appendChild(i),this.viewItems.push(o)):(this.actionsList.insertBefore(i,this.actionsList.children[n]),this.viewItems.splice(n,0,o),n++)})),"number"===typeof this.focusedItem&&this.focus(this.focusedItem),this.refreshRole()}clear(){this.isEmpty()||(this.viewItems=(0,c.AS)(this.viewItems),this.viewItemDisposables.clearAndDisposeAll(),s.w_(this.actionsList),this.refreshRole())}length(){return this.viewItems.length}isEmpty(){return 0===this.viewItems.length}focus(e){let t,i=!1;if(void 0===e?i=!0:"number"===typeof e?t=e:"boolean"===typeof e&&(i=e),i&&"undefined"===typeof this.focusedItem){const e=this.viewItems.findIndex((e=>e.isEnabled()));this.focusedItem=-1===e?void 0:e,this.updateFocus(void 0,void 0,!0)}else void 0!==t&&(this.focusedItem=t),this.updateFocus(void 0,void 0,!0)}focusFirst(){return this.focusedItem=this.length()-1,this.focusNext(!0)}focusLast(){return this.focusedItem=0,this.focusPrevious(!0)}focusNext(e,t){if("undefined"===typeof this.focusedItem)this.focusedItem=this.viewItems.length-1;else if(this.viewItems.length<=1)return!1;const i=this.focusedItem;let s;do{if(!e&&this.options.preventLoopNavigation&&this.focusedItem+1>=this.viewItems.length)return this.focusedItem=i,!1;this.focusedItem=(this.focusedItem+1)%this.viewItems.length,s=this.viewItems[this.focusedItem]}while(this.focusedItem!==i&&(this.options.focusOnlyEnabledItems&&!s.isEnabled()||s.action.id===a.wv.ID));return this.updateFocus(void 0,void 0,t),!0}focusPrevious(e){if("undefined"===typeof this.focusedItem)this.focusedItem=0;else if(this.viewItems.length<=1)return!1;const t=this.focusedItem;let i;do{if(this.focusedItem=this.focusedItem-1,this.focusedItem<0){if(!e&&this.options.preventLoopNavigation)return this.focusedItem=t,!1;this.focusedItem=this.viewItems.length-1}i=this.viewItems[this.focusedItem]}while(this.focusedItem!==t&&(this.options.focusOnlyEnabledItems&&!i.isEnabled()||i.action.id===a.wv.ID));return this.updateFocus(!0),!0}updateFocus(e,t,i=!1){"undefined"===typeof this.focusedItem&&this.actionsList.focus({preventScroll:t}),void 0!==this.previouslyFocusedItem&&this.previouslyFocusedItem!==this.focusedItem&&this.viewItems[this.previouslyFocusedItem]?.blur();const s=void 0!==this.focusedItem?this.viewItems[this.focusedItem]:void 0;if(s){let n=!0;h.Tn(s.focus)||(n=!1),this.options.focusOnlyEnabledItems&&h.Tn(s.isEnabled)&&!s.isEnabled()&&(n=!1),s.action.id===a.wv.ID&&(n=!1),n?(i||this.previouslyFocusedItem!==this.focusedItem)&&(s.focus(e),this.previouslyFocusedItem=this.focusedItem):(this.actionsList.focus({preventScroll:t}),this.previouslyFocusedItem=void 0),n&&s.showHover?.()}}doTrigger(e){if("undefined"===typeof this.focusedItem)return;const t=this.viewItems[this.focusedItem];if(t instanceof r.EH){const i=null===t._context||void 0===t._context?e:t._context;this.run(t._action,i)}}async run(e,t){await this._actionRunner.run(e,t)}dispose(){this._context=void 0,this.viewItems=(0,c.AS)(this.viewItems),this.getContainer().remove(),super.dispose()}}},11007:(e,t,i)=>{"use strict";i.d(t,{xE:()=>d,vr:()=>h,h5:()=>u});var s=i(8597);const n=2e4;let r,o,a,l,c;function h(e){r=document.createElement("div"),r.className="monaco-aria-container";const t=()=>{const e=document.createElement("div");return e.className="monaco-alert",e.setAttribute("role","alert"),e.setAttribute("aria-atomic","true"),r.appendChild(e),e};o=t(),a=t();const i=()=>{const e=document.createElement("div");return e.className="monaco-status",e.setAttribute("aria-live","polite"),e.setAttribute("aria-atomic","true"),r.appendChild(e),e};l=i(),c=i(),e.appendChild(r)}function d(e){r&&(o.textContent!==e?(s.w_(a),g(o,e)):(s.w_(o),g(a,e)))}function u(e){r&&(l.textContent!==e?(s.w_(c),g(l,e)):(s.w_(l),g(c,e)))}function g(e,t){s.w_(e),t.length>n&&(t=t.substr(0,n)),e.textContent=t,e.style.visibility="hidden",e.style.visibility="visible"}},62890:(e,t,i)=>{"use strict";i.d(t,{$:()=>f});var s=i(8597),n=i(83750),r=i(72962),o=i(68214),a=i(25154),l=i(42904),c=i(20370),h=i(47661),d=i(41234),u=i(16980),g=i(5662),p=i(25689),m=i(48196);h.Q1.white.toString(),h.Q1.white.toString();class f extends g.jG{get onDidClick(){return this._onDidClick.event}constructor(e,t){super(),this._label="",this._onDidClick=this._register(new d.vl),this._onDidEscape=this._register(new d.vl),this.options=t,this._element=document.createElement("a"),this._element.classList.add("monaco-button"),this._element.tabIndex=0,this._element.setAttribute("role","button"),this._element.classList.toggle("secondary",!!t.secondary);const i=t.secondary?t.buttonSecondaryBackground:t.buttonBackground,n=t.secondary?t.buttonSecondaryForeground:t.buttonForeground;this._element.style.color=n||"",this._element.style.backgroundColor=i||"",t.supportShortLabel&&(this._labelShortElement=document.createElement("div"),this._labelShortElement.classList.add("monaco-button-label-short"),this._element.appendChild(this._labelShortElement),this._labelElement=document.createElement("div"),this._labelElement.classList.add("monaco-button-label"),this._element.appendChild(this._labelElement),this._element.classList.add("monaco-text-button-with-short-label")),"string"===typeof t.title&&this.setTitle(t.title),"string"===typeof t.ariaLabel&&this._element.setAttribute("aria-label",t.ariaLabel),e.appendChild(this._element),this._register(a.q.addTarget(this._element)),[s.Bx.CLICK,a.B.Tap].forEach((e=>{this._register((0,s.ko)(this._element,e,(e=>{this.enabled?this._onDidClick.fire(e):s.fs.stop(e)})))})),this._register((0,s.ko)(this._element,s.Bx.KEY_DOWN,(e=>{const t=new r.Z(e);let i=!1;this.enabled&&(t.equals(3)||t.equals(10))?(this._onDidClick.fire(e),i=!0):t.equals(9)&&(this._onDidEscape.fire(e),this._element.blur(),i=!0),i&&s.fs.stop(t,!0)}))),this._register((0,s.ko)(this._element,s.Bx.MOUSE_OVER,(e=>{this._element.classList.contains("disabled")||this.updateBackground(!0)}))),this._register((0,s.ko)(this._element,s.Bx.MOUSE_OUT,(e=>{this.updateBackground(!1)}))),this.focusTracker=this._register((0,s.w5)(this._element)),this._register(this.focusTracker.onDidFocus((()=>{this.enabled&&this.updateBackground(!0)}))),this._register(this.focusTracker.onDidBlur((()=>{this.enabled&&this.updateBackground(!1)})))}dispose(){super.dispose(),this._element.remove()}getContentElements(e){const t=[];for(let i of(0,c.n)(e))if("string"===typeof i){if(i=i.trim(),""===i)continue;const e=document.createElement("span");e.textContent=i,t.push(e)}else t.push(i);return t}updateBackground(e){let t;t=this.options.secondary?e?this.options.buttonSecondaryHoverBackground:this.options.buttonSecondaryBackground:e?this.options.buttonHoverBackground:this.options.buttonBackground,t&&(this._element.style.backgroundColor=t)}get element(){return this._element}set label(e){if(this._label===e)return;if((0,u.VS)(this._label)&&(0,u.VS)(e)&&(0,u.nK)(this._label,e))return;this._element.classList.add("monaco-text-button");const t=this.options.supportShortLabel?this._labelElement:this._element;if((0,u.VS)(e)){const i=(0,o.Gc)(e,{inline:!0});i.dispose();const r=i.element.querySelector("p")?.innerHTML;if(r){const e=(0,n.aj)(r,{ADD_TAGS:["b","i","u","code","span"],ALLOWED_ATTR:["class"],RETURN_TRUSTED_TYPE:!0});t.innerHTML=e}else(0,s.Ln)(t)}else this.options.supportIcons?(0,s.Ln)(t,...this.getContentElements(e)):t.textContent=e;let i="";"string"===typeof this.options.title?i=this.options.title:this.options.title&&(i=(0,o.R9)(e)),this.setTitle(i),"string"===typeof this.options.ariaLabel?this._element.setAttribute("aria-label",this.options.ariaLabel):this.options.ariaLabel&&this._element.setAttribute("aria-label",i),this._label=e}get label(){return this._label}set icon(e){this._element.classList.add(...p.L.asClassNameArray(e))}set enabled(e){e?(this._element.classList.remove("disabled"),this._element.setAttribute("aria-disabled",String(!1)),this._element.tabIndex=0):(this._element.classList.add("disabled"),this._element.setAttribute("aria-disabled",String(!0)))}get enabled(){return!this._element.classList.contains("disabled")}setTitle(e){this._hover||""===e?this._hover&&this._hover.update(e):this._hover=this._register((0,m.i)().setupManagedHover(this.options.hoverDelegate??(0,l.nZ)("mouse"),this._element,e))}}},97791:()=>{},3828:(e,t,i)=>{"use strict";i.d(t,{x:()=>r});var s=i(8597),n=i(91508);class r{constructor(e,t,i){this.options=t,this.styles=i,this.count=0,this.element=(0,s.BC)(e,(0,s.$)(".monaco-count-badge")),this.countFormat=this.options.countFormat||"{0}",this.titleFormat=this.options.titleFormat||"",this.setCount(this.options.count||0)}setCount(e){this.count=e,this.render()}setTitleFormat(e){this.titleFormat=e,this.render()}render(){this.element.textContent=(0,n.GP)(this.countFormat,this.count),this.element.title=(0,n.GP)(this.titleFormat,this.count),this.element.style.backgroundColor=this.styles.badgeBackground??"",this.element.style.color=this.styles.badgeForeground??"",this.styles.badgeBorder&&(this.element.style.border=`1px solid ${this.styles.badgeBorder}`)}}},89506:(e,t,i)=>{"use strict";i.d(t,{d:()=>g});var s=i(8597),n=i(5646),r=i(72962),o=i(25154),a=i(36921),l=i(41234);class c extends a.LN{constructor(e,t){super(),this._onDidChangeVisibility=this._register(new l.vl),this.onDidChangeVisibility=this._onDidChangeVisibility.event,this._element=(0,s.BC)(e,(0,s.$)(".monaco-dropdown")),this._label=(0,s.BC)(this._element,(0,s.$)(".dropdown-label"));let i=t.labelRenderer;i||(i=e=>(e.textContent=t.label||"",null));for(const r of[s.Bx.CLICK,s.Bx.MOUSE_DOWN,o.B.Tap])this._register((0,s.ko)(this.element,r,(e=>s.fs.stop(e,!0))));for(const r of[s.Bx.MOUSE_DOWN,o.B.Tap])this._register((0,s.ko)(this._label,r,(e=>{(0,s.Er)(e)&&(e.detail>1||0!==e.button)||(this.visible?this.hide():this.show())})));this._register((0,s.ko)(this._label,s.Bx.KEY_UP,(e=>{const t=new r.Z(e);(t.equals(3)||t.equals(10))&&(s.fs.stop(e,!0),this.visible?this.hide():this.show())})));const n=i(this._label);n&&this._register(n),this._register(o.q.addTarget(this._label))}get element(){return this._element}show(){this.visible||(this.visible=!0,this._onDidChangeVisibility.fire(!0))}hide(){this.visible&&(this.visible=!1,this._onDidChangeVisibility.fire(!1))}dispose(){super.dispose(),this.hide(),this.boxContainer&&(this.boxContainer.remove(),this.boxContainer=void 0),this.contents&&(this.contents.remove(),this.contents=void 0),this._label&&(this._label.remove(),this._label=void 0)}}class h extends c{constructor(e,t){super(e,t),this._options=t,this._actions=[],this.actions=t.actions||[]}set menuOptions(e){this._menuOptions=e}get menuOptions(){return this._menuOptions}get actions(){return this._options.actionProvider?this._options.actionProvider.getActions():this._actions}set actions(e){this._actions=e}show(){super.show(),this.element.classList.add("active"),this._options.contextMenuProvider.showContextMenu({getAnchor:()=>this.element,getActions:()=>this.actions,getActionsContext:()=>this.menuOptions?this.menuOptions.context:null,getActionViewItem:(e,t)=>this.menuOptions&&this.menuOptions.actionViewItemProvider?this.menuOptions.actionViewItemProvider(e,t):void 0,getKeyBinding:e=>this.menuOptions&&this.menuOptions.getKeyBinding?this.menuOptions.getKeyBinding(e):void 0,getMenuClassName:()=>this._options.menuClassName||"",onHide:()=>this.onHide(),actionRunner:this.menuOptions?this.menuOptions.actionRunner:void 0,anchorAlignment:this.menuOptions?this.menuOptions.anchorAlignment:0,domForShadowRoot:this._options.menuAsChild?this.element:void 0,skipTelemetry:this._options.skipTelemetry})}hide(){super.hide()}onHide(){this.hide(),this.element.classList.remove("active")}}var d=i(42904),u=i(48196);class g extends n.EH{constructor(e,t,i,s=Object.create(null)){super(null,e,s),this.actionItem=null,this._onDidChangeVisibility=this._register(new l.vl),this.onDidChangeVisibility=this._onDidChangeVisibility.event,this.menuActionsOrProvider=t,this.contextMenuProvider=i,this.options=s,this.options.actionRunner&&(this.actionRunner=this.options.actionRunner)}render(e){this.actionItem=e;const t=Array.isArray(this.menuActionsOrProvider),i={contextMenuProvider:this.contextMenuProvider,labelRenderer:e=>{this.element=(0,s.BC)(e,(0,s.$)("a.action-label"));let t=[];return"string"===typeof this.options.classNames?t=this.options.classNames.split(/\s+/g).filter((e=>!!e)):this.options.classNames&&(t=this.options.classNames),t.find((e=>"icon"===e))||t.push("codicon"),this.element.classList.add(...t),this.element.setAttribute("role","button"),this.element.setAttribute("aria-haspopup","true"),this.element.setAttribute("aria-expanded","false"),this._action.label&&this._register((0,u.i)().setupManagedHover(this.options.hoverDelegate??(0,d.nZ)("mouse"),this.element,this._action.label)),this.element.ariaLabel=this._action.label||"",null},menuAsChild:this.options.menuAsChild,actions:t?this.menuActionsOrProvider:void 0,actionProvider:t?void 0:this.menuActionsOrProvider,skipTelemetry:this.options.skipTelemetry};if(this.dropdownMenu=this._register(new h(e,i)),this._register(this.dropdownMenu.onDidChangeVisibility((e=>{this.element?.setAttribute("aria-expanded",`${e}`),this._onDidChangeVisibility.fire(e)}))),this.dropdownMenu.menuOptions={actionViewItemProvider:this.options.actionViewItemProvider,actionRunner:this.actionRunner,getKeyBinding:this.options.keybindingProvider,context:this._context},this.options.anchorAlignmentProvider){const e=this;this.dropdownMenu.menuOptions={...this.dropdownMenu.menuOptions,get anchorAlignment(){return e.options.anchorAlignmentProvider()}}}this.updateTooltip(),this.updateEnabled()}getTooltip(){let e=null;return this.action.tooltip?e=this.action.tooltip:this.action.label&&(e=this.action.label),e??void 0}setActionContext(e){super.setActionContext(e),this.dropdownMenu&&(this.dropdownMenu.menuOptions?this.dropdownMenu.menuOptions.context=e:this.dropdownMenu.menuOptions={context:e})}show(){this.dropdownMenu?.show()}updateEnabled(){const e=!this.action.enabled;this.actionItem?.classList.toggle("disabled",e),this.element?.classList.toggle("disabled",e)}}},88443:(e,t,i)=>{"use strict";i.d(t,{c:()=>u});var s=i(8597),n=i(23034),r=i(91581),o=i(17390),a=i(41234),l=(i(10713),i(78209)),c=i(5662),h=i(42904);const d=l.kg("defaultLabel","input");class u extends o.x{constructor(e,t,i){super(),this.fixFocusOnOptionClickEnabled=!0,this.imeSessionInProgress=!1,this.additionalTogglesDisposables=this._register(new c.HE),this.additionalToggles=[],this._onDidOptionChange=this._register(new a.vl),this.onDidOptionChange=this._onDidOptionChange.event,this._onKeyDown=this._register(new a.vl),this.onKeyDown=this._onKeyDown.event,this._onMouseDown=this._register(new a.vl),this.onMouseDown=this._onMouseDown.event,this._onInput=this._register(new a.vl),this._onKeyUp=this._register(new a.vl),this._onCaseSensitiveKeyDown=this._register(new a.vl),this.onCaseSensitiveKeyDown=this._onCaseSensitiveKeyDown.event,this._onRegexKeyDown=this._register(new a.vl),this.onRegexKeyDown=this._onRegexKeyDown.event,this._lastHighlightFindOptions=0,this.placeholder=i.placeholder||"",this.validation=i.validation,this.label=i.label||d,this.showCommonFindToggles=!!i.showCommonFindToggles;const o=i.appendCaseSensitiveLabel||"",l=i.appendWholeWordsLabel||"",u=i.appendRegexLabel||"",g=i.history||[],p=!!i.flexibleHeight,m=!!i.flexibleWidth,f=i.flexibleMaxHeight;this.domNode=document.createElement("div"),this.domNode.classList.add("monaco-findInput"),this.inputBox=this._register(new r.mJ(this.domNode,t,{placeholder:this.placeholder||"",ariaLabel:this.label||"",validationOptions:{validation:this.validation},history:g,showHistoryHint:i.showHistoryHint,flexibleHeight:p,flexibleWidth:m,flexibleMaxHeight:f,inputBoxStyles:i.inputBoxStyles}));const _=this._register((0,h.bW)());if(this.showCommonFindToggles){this.regex=this._register(new n.Ix({appendTitle:u,isChecked:!1,hoverDelegate:_,...i.toggleStyles})),this._register(this.regex.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this._register(this.regex.onKeyDown((e=>{this._onRegexKeyDown.fire(e)}))),this.wholeWords=this._register(new n.nV({appendTitle:l,isChecked:!1,hoverDelegate:_,...i.toggleStyles})),this._register(this.wholeWords.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this.caseSensitive=this._register(new n.bc({appendTitle:o,isChecked:!1,hoverDelegate:_,...i.toggleStyles})),this._register(this.caseSensitive.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this._register(this.caseSensitive.onKeyDown((e=>{this._onCaseSensitiveKeyDown.fire(e)})));const e=[this.caseSensitive.domNode,this.wholeWords.domNode,this.regex.domNode];this.onkeydown(this.domNode,(t=>{if(t.equals(15)||t.equals(17)||t.equals(9)){const i=e.indexOf(this.domNode.ownerDocument.activeElement);if(i>=0){let n=-1;t.equals(17)?n=(i+1)%e.length:t.equals(15)&&(n=0===i?e.length-1:i-1),t.equals(9)?(e[i].blur(),this.inputBox.focus()):n>=0&&e[n].focus(),s.fs.stop(t,!0)}}}))}this.controls=document.createElement("div"),this.controls.className="controls",this.controls.style.display=this.showCommonFindToggles?"":"none",this.caseSensitive&&this.controls.append(this.caseSensitive.domNode),this.wholeWords&&this.controls.appendChild(this.wholeWords.domNode),this.regex&&this.controls.appendChild(this.regex.domNode),this.setAdditionalToggles(i?.additionalToggles),this.controls&&this.domNode.appendChild(this.controls),e?.appendChild(this.domNode),this._register(s.ko(this.inputBox.inputElement,"compositionstart",(e=>{this.imeSessionInProgress=!0}))),this._register(s.ko(this.inputBox.inputElement,"compositionend",(e=>{this.imeSessionInProgress=!1,this._onInput.fire()}))),this.onkeydown(this.inputBox.inputElement,(e=>this._onKeyDown.fire(e))),this.onkeyup(this.inputBox.inputElement,(e=>this._onKeyUp.fire(e))),this.oninput(this.inputBox.inputElement,(e=>this._onInput.fire())),this.onmousedown(this.inputBox.inputElement,(e=>this._onMouseDown.fire(e)))}get onDidChange(){return this.inputBox.onDidChange}layout(e){this.inputBox.layout(),this.updateInputBoxPadding(e.collapsedFindWidget)}enable(){this.domNode.classList.remove("disabled"),this.inputBox.enable(),this.regex?.enable(),this.wholeWords?.enable(),this.caseSensitive?.enable();for(const e of this.additionalToggles)e.enable()}disable(){this.domNode.classList.add("disabled"),this.inputBox.disable(),this.regex?.disable(),this.wholeWords?.disable(),this.caseSensitive?.disable();for(const e of this.additionalToggles)e.disable()}setFocusInputOnOptionClick(e){this.fixFocusOnOptionClickEnabled=e}setEnabled(e){e?this.enable():this.disable()}setAdditionalToggles(e){for(const t of this.additionalToggles)t.domNode.remove();this.additionalToggles=[],this.additionalTogglesDisposables.value=new c.Cm;for(const t of e??[])this.additionalTogglesDisposables.value.add(t),this.controls.appendChild(t.domNode),this.additionalTogglesDisposables.value.add(t.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus()}))),this.additionalToggles.push(t);this.additionalToggles.length>0&&(this.controls.style.display=""),this.updateInputBoxPadding()}updateInputBoxPadding(e=!1){this.inputBox.paddingRight=e?0:(this.caseSensitive?.width()??0)+(this.wholeWords?.width()??0)+(this.regex?.width()??0)+this.additionalToggles.reduce(((e,t)=>e+t.width()),0)}getValue(){return this.inputBox.value}setValue(e){this.inputBox.value!==e&&(this.inputBox.value=e)}select(){this.inputBox.select()}focus(){this.inputBox.focus()}getCaseSensitive(){return this.caseSensitive?.checked??!1}setCaseSensitive(e){this.caseSensitive&&(this.caseSensitive.checked=e)}getWholeWords(){return this.wholeWords?.checked??!1}setWholeWords(e){this.wholeWords&&(this.wholeWords.checked=e)}getRegex(){return this.regex?.checked??!1}setRegex(e){this.regex&&(this.regex.checked=e,this.validate())}focusOnCaseSensitive(){this.caseSensitive?.focus()}highlightFindOptions(){this.domNode.classList.remove("highlight-"+this._lastHighlightFindOptions),this._lastHighlightFindOptions=1-this._lastHighlightFindOptions,this.domNode.classList.add("highlight-"+this._lastHighlightFindOptions)}validate(){this.inputBox.validate()}showMessage(e){this.inputBox.showMessage(e)}clearMessage(){this.inputBox.hideMessage()}}},23034:(e,t,i)=>{"use strict";i.d(t,{Ix:()=>u,bc:()=>h,nV:()=>d});var s=i(42904),n=i(35315),r=i(10350),o=i(78209);const a=o.kg("caseDescription","Match Case"),l=o.kg("wordsDescription","Match Whole Word"),c=o.kg("regexDescription","Use Regular Expression");class h extends n.l{constructor(e){super({icon:r.W.caseSensitive,title:a+e.appendTitle,isChecked:e.isChecked,hoverDelegate:e.hoverDelegate??(0,s.nZ)("element"),inputActiveOptionBorder:e.inputActiveOptionBorder,inputActiveOptionForeground:e.inputActiveOptionForeground,inputActiveOptionBackground:e.inputActiveOptionBackground})}}class d extends n.l{constructor(e){super({icon:r.W.wholeWord,title:l+e.appendTitle,isChecked:e.isChecked,hoverDelegate:e.hoverDelegate??(0,s.nZ)("element"),inputActiveOptionBorder:e.inputActiveOptionBorder,inputActiveOptionForeground:e.inputActiveOptionForeground,inputActiveOptionBackground:e.inputActiveOptionBackground})}}class u extends n.l{constructor(e){super({icon:r.W.regex,title:c+e.appendTitle,isChecked:e.isChecked,hoverDelegate:e.hoverDelegate??(0,s.nZ)("element"),inputActiveOptionBorder:e.inputActiveOptionBorder,inputActiveOptionForeground:e.inputActiveOptionForeground,inputActiveOptionBackground:e.inputActiveOptionBackground})}}},37479:(e,t,i)=>{"use strict";i.d(t,{_:()=>c});var s=i(8597),n=i(48196),r=i(42904),o=i(20370),a=i(5662),l=i(10146);class c extends a.jG{constructor(e,t){super(),this.options=t,this.text="",this.title="",this.highlights=[],this.didEverRender=!1,this.supportIcons=t?.supportIcons??!1,this.domNode=s.BC(e,s.$("span.monaco-highlighted-label"))}get element(){return this.domNode}set(e,t=[],i="",s){e||(e=""),s&&(e=c.escapeNewLines(e,t)),this.didEverRender&&this.text===e&&this.title===i&&l.aI(this.highlights,t)||(this.text=e,this.title=i,this.highlights=t,this.render())}render(){const e=[];let t=0;for(const i of this.highlights){if(i.end===i.start)continue;if(t{s="\r\n"===e?-1:0,n+=i;for(const i of t)i.end<=n||(i.start>=n&&(i.start+=s),i.end>=n&&(i.end+=s));return i+=s,"\u23ce"}))}}},48196:(e,t,i)=>{"use strict";i.d(t,{e:()=>n,i:()=>r});let s={showHover:()=>{},hideHover:()=>{},showAndFocusLastHover:()=>{},setupManagedHover:()=>null,showManagedHover:()=>{}};function n(e){s=e}function r(){return s}},42904:(e,t,i)=>{"use strict";i.d(t,{MW:()=>a,bW:()=>c,nZ:()=>l});var s=i(91090);let n=()=>({get delay(){return-1},dispose:()=>{},showHover:()=>{}});const r=new s.d((()=>n("mouse",!1))),o=new s.d((()=>n("element",!1)));function a(e){n=e}function l(e){return"element"===e?o.value:r.value}function c(){return n("element",!0)}},52776:(e,t,i)=>{"use strict";i.d(t,{vV:()=>u,jQ:()=>h,N4:()=>c,M4:()=>g,vr:()=>d});var s=i(8597),n=i(72962),r=i(31295),o=i(5662),a=i(78209);const l=s.$;class c extends o.jG{constructor(){super(),this.containerDomNode=document.createElement("div"),this.containerDomNode.className="monaco-hover",this.containerDomNode.tabIndex=0,this.containerDomNode.setAttribute("role","tooltip"),this.contentsDomNode=document.createElement("div"),this.contentsDomNode.className="monaco-hover-content",this.scrollbar=this._register(new r.MU(this.contentsDomNode,{consumeMouseWheelIfScrollbarIsNeeded:!0})),this.containerDomNode.appendChild(this.scrollbar.getDomNode())}onContentsChanged(){this.scrollbar.scanDomNode()}}class h extends o.jG{static render(e,t,i){return new h(e,t,i)}constructor(e,t,i){super(),this.actionLabel=t.label,this.actionKeybindingLabel=i,this.actionContainer=s.BC(e,l("div.action-container")),this.actionContainer.setAttribute("tabindex","0"),this.action=s.BC(this.actionContainer,l("a.action")),this.action.setAttribute("role","button"),t.iconClass&&s.BC(this.action,l(`span.icon.${t.iconClass}`));s.BC(this.action,l("span")).textContent=i?`${t.label} (${i})`:t.label,this._store.add(new u(this.actionContainer,t.run)),this._store.add(new g(this.actionContainer,t.run,[3,10])),this.setEnabled(!0)}setEnabled(e){e?(this.actionContainer.classList.remove("disabled"),this.actionContainer.removeAttribute("aria-disabled")):(this.actionContainer.classList.add("disabled"),this.actionContainer.setAttribute("aria-disabled","true"))}}function d(e,t){return e&&t?(0,a.kg)("acessibleViewHint","Inspect this in the accessible view with {0}.",t):e?(0,a.kg)("acessibleViewHintNoKbOpen","Inspect this in the accessible view via the command Open Accessible View which is currently not triggerable via keybinding."):""}class u extends o.jG{constructor(e,t){super(),this._register(s.ko(e,s.Bx.CLICK,(i=>{i.stopPropagation(),i.preventDefault(),t(e)})))}}class g extends o.jG{constructor(e,t,i){super(),this._register(s.ko(e,s.Bx.KEY_DOWN,(s=>{const r=new n.Z(s);i.some((e=>r.equals(e)))&&(s.stopPropagation(),s.preventDefault(),t(e))})))}}},21852:(e,t,i)=>{"use strict";i.d(t,{s:()=>g});var s=i(8597),n=i(37479),r=i(5662),o=i(10146),a=i(92719),l=i(42904),c=i(48196),h=i(631),d=i(37882);class u{constructor(e){this._element=e}get element(){return this._element}set textContent(e){this.disposed||e===this._textContent||(this._textContent=e,this._element.textContent=e)}set classNames(e){this.disposed||(0,o.aI)(e,this._classNames)||(this._classNames=e,this._element.classList.value="",this._element.classList.add(...e))}set empty(e){this.disposed||e===this._empty||(this._empty=e,this._element.style.marginLeft=e?"0":"")}dispose(){this.disposed=!0}}class g extends r.jG{constructor(e,t){super(),this.customHovers=new Map,this.creationOptions=t,this.domNode=this._register(new u(s.BC(e,s.$(".monaco-icon-label")))),this.labelContainer=s.BC(this.domNode.element,s.$(".monaco-icon-label-container")),this.nameContainer=s.BC(this.labelContainer,s.$("span.monaco-icon-name-container")),this.nameNode=t?.supportHighlights||t?.supportIcons?this._register(new m(this.nameContainer,!!t.supportIcons)):new p(this.nameContainer),this.hoverDelegate=t?.hoverDelegate??(0,l.nZ)("mouse")}get element(){return this.domNode.element}setLabel(e,t,i){const r=["monaco-icon-label"],o=["monaco-icon-label-container"];let a="";i&&(i.extraClasses&&r.push(...i.extraClasses),i.italic&&r.push("italic"),i.strikethrough&&r.push("strikethrough"),i.disabledCommand&&o.push("disabled"),i.title&&("string"===typeof i.title?a+=i.title:a+=e));const l=this.domNode.element.querySelector(".monaco-icon-label-iconpath");if(i?.iconPath){let e;l&&s.sb(l)?e=l:(e=s.$(".monaco-icon-label-iconpath"),this.domNode.element.prepend(e)),e.style.backgroundImage=s.Tf(i?.iconPath)}else l&&l.remove();if(this.domNode.classNames=r,this.domNode.element.setAttribute("aria-label",a),this.labelContainer.classList.value="",this.labelContainer.classList.add(...o),this.setupHover(i?.descriptionTitle?this.labelContainer:this.element,i?.title),this.nameNode.setLabel(e,i),t||this.descriptionNode){const e=this.getOrCreateDescriptionNode();e instanceof n._?(e.set(t||"",i?i.descriptionMatches:void 0,void 0,i?.labelEscapeNewLines),this.setupHover(e.element,i?.descriptionTitle)):(e.textContent=t&&i?.labelEscapeNewLines?n._.escapeNewLines(t,[]):t||"",this.setupHover(e.element,i?.descriptionTitle||""),e.empty=!t)}if(i?.suffix||this.suffixNode){this.getOrCreateSuffixNode().textContent=i?.suffix??""}}setupHover(e,t){const i=this.customHovers.get(e);if(i&&(i.dispose(),this.customHovers.delete(e)),t)if(this.hoverDelegate.showNativeHover){function s(e,t){(0,h.Kg)(t)?e.title=(0,d.pS)(t):t?.markdownNotSupportedFallback?e.title=t.markdownNotSupportedFallback:e.removeAttribute("title")}s(e,t)}else{const n=(0,c.i)().setupManagedHover(this.hoverDelegate,e,t);n&&this.customHovers.set(e,n)}else e.removeAttribute("title")}dispose(){super.dispose();for(const e of this.customHovers.values())e.dispose();this.customHovers.clear()}getOrCreateSuffixNode(){if(!this.suffixNode){const e=this._register(new u(s.Pl(this.nameContainer,s.$("span.monaco-icon-suffix-container"))));this.suffixNode=this._register(new u(s.BC(e.element,s.$("span.label-suffix"))))}return this.suffixNode}getOrCreateDescriptionNode(){if(!this.descriptionNode){const e=this._register(new u(s.BC(this.labelContainer,s.$("span.monaco-icon-description-container"))));this.creationOptions?.supportDescriptionHighlights?this.descriptionNode=this._register(new n._(s.BC(e.element,s.$("span.label-description")),{supportIcons:!!this.creationOptions.supportIcons})):this.descriptionNode=this._register(new u(s.BC(e.element,s.$("span.label-description"))))}return this.descriptionNode}}class p{constructor(e){this.container=e,this.label=void 0,this.singleLabel=void 0}setLabel(e,t){if(this.label!==e||!(0,o.aI)(this.options,t))if(this.label=e,this.options=t,"string"===typeof e)this.singleLabel||(this.container.innerText="",this.container.classList.remove("multiple"),this.singleLabel=s.BC(this.container,s.$("a.label-name",{id:t?.domId}))),this.singleLabel.textContent=e;else{this.container.innerText="",this.container.classList.add("multiple"),this.singleLabel=void 0;for(let i=0;i{const n={start:s,end:s+e.length},r=i.map((e=>a.Q.intersect(n,e))).filter((e=>!a.Q.isEmpty(e))).map((({start:e,end:t})=>({start:e-s,end:t-s})));return s=n.end+t.length,r}))}(e,i,t?.matches);for(let o=0;o{"use strict";i.d(t,{n:()=>o,s:()=>a});var s=i(8597),n=i(25689);const r=new RegExp(`(\\\\)?\\$\\((${n.L.iconNameExpression}(?:${n.L.iconModifierExpression})?)\\)`,"g");function o(e){const t=new Array;let i,s=0,n=0;for(;null!==(i=r.exec(e));){n=i.index||0,s{"use strict";i.d(t,{mJ:()=>b,x8:()=>v});var s=i(8597),n=i(56245),r=i(27661),o=i(11799),a=i(11007),l=i(48196),c=i(42904),h=i(31295),d=i(17390),u=i(41234);class g{constructor(e,t=0,i=e.length,s=t-1){this.items=e,this.start=t,this.end=i,this.index=s}current(){return this.index===this.start-1||this.index===this.end?null:this.items[this.index]}next(){return this.index=Math.min(this.index+1,this.end),this.current()}previous(){return this.index=Math.max(this.index-1,this.start-1),this.current()}first(){return this.index=this.start,this.current()}last(){return this.index=this.end-1,this.current()}}class p{constructor(e=[],t=10){this._initialize(e),this._limit=t,this._onChange()}getHistory(){return this._elements}add(e){this._history.delete(e),this._history.add(e),this._onChange()}next(){return this._navigator.next()}previous(){return 0!==this._currentPosition()?this._navigator.previous():null}current(){return this._navigator.current()}first(){return this._navigator.first()}last(){return this._navigator.last()}isLast(){return this._currentPosition()>=this._elements.length-1}isNowhere(){return null===this._navigator.current()}has(e){return this._history.has(e)}_onChange(){this._reduceToLimit();const e=this._elements;this._navigator=new g(e,0,e.length,e.length)}_reduceToLimit(){const e=this._elements;e.length>this._limit&&this._initialize(e.slice(e.length-this._limit))}_currentPosition(){const e=this._navigator.current();return e?this._elements.indexOf(e):-1}_initialize(e){this._history=new Set;for(const t of e)this._history.add(t)}get _elements(){const e=[];return this._history.forEach((t=>e.push(t))),e}}var m=i(10146),f=i(78209);const _=s.$,v={inputBackground:"#3C3C3C",inputForeground:"#CCCCCC",inputValidationInfoBorder:"#55AAFF",inputValidationInfoBackground:"#063B49",inputValidationWarningBorder:"#B89500",inputValidationWarningBackground:"#352A05",inputValidationErrorBorder:"#BE1100",inputValidationErrorBackground:"#5A1D1D",inputBorder:void 0,inputValidationErrorForeground:void 0,inputValidationInfoForeground:void 0,inputValidationWarningForeground:void 0};class C extends d.x{constructor(e,t,i){super(),this.state="idle",this.maxHeight=Number.POSITIVE_INFINITY,this._onDidChange=this._register(new u.vl),this.onDidChange=this._onDidChange.event,this._onDidHeightChange=this._register(new u.vl),this.onDidHeightChange=this._onDidHeightChange.event,this.contextViewProvider=t,this.options=i,this.message=null,this.placeholder=this.options.placeholder||"",this.tooltip=this.options.tooltip??(this.placeholder||""),this.ariaLabel=this.options.ariaLabel||"",this.options.validationOptions&&(this.validation=this.options.validationOptions.validation),this.element=s.BC(e,_(".monaco-inputbox.idle"));const r=this.options.flexibleHeight?"textarea":"input",a=s.BC(this.element,_(".ibwrapper"));if(this.input=s.BC(a,_(r+".input.empty")),this.input.setAttribute("autocorrect","off"),this.input.setAttribute("autocapitalize","off"),this.input.setAttribute("spellcheck","false"),this.onfocus(this.input,(()=>this.element.classList.add("synthetic-focus"))),this.onblur(this.input,(()=>this.element.classList.remove("synthetic-focus"))),this.options.flexibleHeight){this.maxHeight="number"===typeof this.options.flexibleMaxHeight?this.options.flexibleMaxHeight:Number.POSITIVE_INFINITY,this.mirror=s.BC(a,_("div.mirror")),this.mirror.innerText="\xa0",this.scrollableElement=new h.Se(this.element,{vertical:1}),this.options.flexibleWidth&&(this.input.setAttribute("wrap","off"),this.mirror.style.whiteSpace="pre",this.mirror.style.wordWrap="initial"),s.BC(e,this.scrollableElement.getDomNode()),this._register(this.scrollableElement),this._register(this.scrollableElement.onScroll((e=>this.input.scrollTop=e.scrollTop)));const t=this._register(new n.f(e.ownerDocument,"selectionchange")),i=u.Jh.filter(t.event,(()=>{const t=e.ownerDocument.getSelection();return t?.anchorNode===a}));this._register(i(this.updateScrollDimensions,this)),this._register(this.onDidHeightChange(this.updateScrollDimensions,this))}else this.input.type=this.options.type||"text",this.input.setAttribute("wrap","off");this.ariaLabel&&this.input.setAttribute("aria-label",this.ariaLabel),this.placeholder&&!this.options.showPlaceholderOnFocus&&this.setPlaceHolder(this.placeholder),this.tooltip&&this.setTooltip(this.tooltip),this.oninput(this.input,(()=>this.onValueChange())),this.onblur(this.input,(()=>this.onBlur())),this.onfocus(this.input,(()=>this.onFocus())),this._register(this.ignoreGesture(this.input)),setTimeout((()=>this.updateMirror()),0),this.options.actions&&(this.actionbar=this._register(new o.E(this.element)),this.actionbar.push(this.options.actions,{icon:!0,label:!1})),this.applyStyles()}onBlur(){this._hideMessage(),this.options.showPlaceholderOnFocus&&this.input.setAttribute("placeholder","")}onFocus(){this._showMessage(),this.options.showPlaceholderOnFocus&&this.input.setAttribute("placeholder",this.placeholder||"")}setPlaceHolder(e){this.placeholder=e,this.input.setAttribute("placeholder",e)}setTooltip(e){this.tooltip=e,this.hover?this.hover.update(e):this.hover=this._register((0,l.i)().setupManagedHover((0,c.nZ)("mouse"),this.input,e))}get inputElement(){return this.input}get value(){return this.input.value}set value(e){this.input.value!==e&&(this.input.value=e,this.onValueChange())}get height(){return"number"===typeof this.cachedHeight?this.cachedHeight:s.OK(this.element)}focus(){this.input.focus()}blur(){this.input.blur()}hasFocus(){return s.X7(this.input)}select(e=null){this.input.select(),e&&(this.input.setSelectionRange(e.start,e.end),e.end===this.input.value.length&&(this.input.scrollLeft=this.input.scrollWidth))}isSelectionAtEnd(){return this.input.selectionEnd===this.input.value.length&&this.input.selectionStart===this.input.selectionEnd}getSelection(){const e=this.input.selectionStart;if(null===e)return null;return{start:e,end:this.input.selectionEnd??e}}enable(){this.input.removeAttribute("disabled")}disable(){this.blur(),this.input.disabled=!0,this._hideMessage()}set paddingRight(e){this.input.style.width=`calc(100% - ${e}px)`,this.mirror&&(this.mirror.style.paddingRight=e+"px")}updateScrollDimensions(){if("number"!==typeof this.cachedContentHeight||"number"!==typeof this.cachedHeight||!this.scrollableElement)return;const e=this.cachedContentHeight,t=this.cachedHeight,i=this.input.scrollTop;this.scrollableElement.setScrollDimensions({scrollHeight:e,height:t}),this.scrollableElement.setScrollPosition({scrollTop:i})}showMessage(e,t){if("open"===this.state&&(0,m.aI)(this.message,e))return;this.message=e,this.element.classList.remove("idle"),this.element.classList.remove("info"),this.element.classList.remove("warning"),this.element.classList.remove("error"),this.element.classList.add(this.classForType(e.type));const i=this.stylesForType(this.message.type);this.element.style.border=`1px solid ${s.gI(i.border,"transparent")}`,this.message.content&&(this.hasFocus()||t)&&this._showMessage()}hideMessage(){this.message=null,this.element.classList.remove("info"),this.element.classList.remove("warning"),this.element.classList.remove("error"),this.element.classList.add("idle"),this._hideMessage(),this.applyStyles()}validate(){let e=null;return this.validation&&(e=this.validation(this.value),e?(this.inputElement.setAttribute("aria-invalid","true"),this.showMessage(e)):this.inputElement.hasAttribute("aria-invalid")&&(this.inputElement.removeAttribute("aria-invalid"),this.hideMessage())),e?.type}stylesForType(e){const t=this.options.inputBoxStyles;switch(e){case 1:return{border:t.inputValidationInfoBorder,background:t.inputValidationInfoBackground,foreground:t.inputValidationInfoForeground};case 2:return{border:t.inputValidationWarningBorder,background:t.inputValidationWarningBackground,foreground:t.inputValidationWarningForeground};default:return{border:t.inputValidationErrorBorder,background:t.inputValidationErrorBackground,foreground:t.inputValidationErrorForeground}}}classForType(e){switch(e){case 1:return"info";case 2:return"warning";default:return"error"}}_showMessage(){if(!this.contextViewProvider||!this.message)return;let e;const t=()=>e.style.width=s.Tr(this.element)+"px";let i;this.contextViewProvider.showContextView({getAnchor:()=>this.element,anchorAlignment:1,render:i=>{if(!this.message)return null;e=s.BC(i,_(".monaco-inputbox-container")),t();const n={inline:!0,className:"monaco-inputbox-message"},o=this.message.formatContent?(0,r.yk)(this.message.content,n):(0,r.S5)(this.message.content,n);o.classList.add(this.classForType(this.message.type));const a=this.stylesForType(this.message.type);return o.style.backgroundColor=a.background??"",o.style.color=a.foreground??"",o.style.border=a.border?`1px solid ${a.border}`:"",s.BC(e,o),null},onHide:()=>{this.state="closed"},layout:t}),i=3===this.message.type?f.kg("alertErrorMessage","Error: {0}",this.message.content):2===this.message.type?f.kg("alertWarningMessage","Warning: {0}",this.message.content):f.kg("alertInfoMessage","Info: {0}",this.message.content),a.xE(i),this.state="open"}_hideMessage(){this.contextViewProvider&&("open"===this.state&&this.contextViewProvider.hideContextView(),this.state="idle")}onValueChange(){this._onDidChange.fire(this.value),this.validate(),this.updateMirror(),this.input.classList.toggle("empty",!this.value),"open"===this.state&&this.contextViewProvider&&this.contextViewProvider.layout()}updateMirror(){if(!this.mirror)return;const e=this.value,t=10===e.charCodeAt(e.length-1)?" ":"";(e+t).replace(/\u000c/g,"")?this.mirror.textContent=e+t:this.mirror.innerText="\xa0",this.layout()}applyStyles(){const e=this.options.inputBoxStyles,t=e.inputBackground??"",i=e.inputForeground??"",n=e.inputBorder??"";this.element.style.backgroundColor=t,this.element.style.color=i,this.input.style.backgroundColor="inherit",this.input.style.color=i,this.element.style.border=`1px solid ${s.gI(n,"transparent")}`}layout(){if(!this.mirror)return;const e=this.cachedContentHeight;this.cachedContentHeight=s.OK(this.mirror),e!==this.cachedContentHeight&&(this.cachedHeight=Math.min(this.cachedContentHeight,this.maxHeight),this.input.style.height=this.cachedHeight+"px",this._onDidHeightChange.fire(this.cachedContentHeight))}insertAtCursor(e){const t=this.inputElement,i=t.selectionStart,s=t.selectionEnd,n=t.value;null!==i&&null!==s&&(this.value=n.substr(0,i)+e+n.substr(s),t.setSelectionRange(i+1,i+1),this.layout())}dispose(){this._hideMessage(),this.message=null,this.actionbar?.dispose(),super.dispose()}}class b extends C{constructor(e,t,i){const n=f.kg({key:"history.inputbox.hint.suffix.noparens",comment:['Text is the suffix of an input field placeholder coming after the action the input field performs, this will be used when the input field ends in a closing parenthesis ")", for example "Filter (e.g. text, !exclude)". The character inserted into the final string is \u21c5 to represent the up and down arrow keys.']}," or {0} for history","\u21c5"),r=f.kg({key:"history.inputbox.hint.suffix.inparens",comment:['Text is the suffix of an input field placeholder coming after the action the input field performs, this will be used when the input field does NOT end in a closing parenthesis (eg. "Find"). The character inserted into the final string is \u21c5 to represent the up and down arrow keys.']}," ({0} for history)","\u21c5");super(e,t,i),this._onDidFocus=this._register(new u.vl),this.onDidFocus=this._onDidFocus.event,this._onDidBlur=this._register(new u.vl),this.onDidBlur=this._onDidBlur.event,this.history=new p(i.history,100);const o=()=>{if(i.showHistoryHint&&i.showHistoryHint()&&!this.placeholder.endsWith(n)&&!this.placeholder.endsWith(r)&&this.history.getHistory().length){const e=this.placeholder.endsWith(")")?n:r,t=this.placeholder+e;i.showPlaceholderOnFocus&&!s.X7(this.input)?this.placeholder=t:this.setPlaceHolder(t)}};this.observer=new MutationObserver(((e,t)=>{e.forEach((e=>{e.target.textContent||o()}))})),this.observer.observe(this.input,{attributeFilter:["class"]}),this.onfocus(this.input,(()=>o())),this.onblur(this.input,(()=>{const e=e=>{if(this.placeholder.endsWith(e)){const t=this.placeholder.slice(0,this.placeholder.length-e.length);return i.showPlaceholderOnFocus?this.placeholder=t:this.setPlaceHolder(t),!0}return!1};e(r)||e(n)}))}dispose(){super.dispose(),this.observer&&(this.observer.disconnect(),this.observer=void 0)}addToHistory(e){this.value&&(e||this.value!==this.getCurrentValue())&&this.history.add(this.value)}isAtLastInHistory(){return this.history.isLast()}isNowhereInHistory(){return this.history.isNowhere()}showNextValue(){this.history.has(this.value)||this.addToHistory();let e=this.getNextValue();e&&(e=e===this.value?this.getNextValue():e),this.value=e??"",a.h5(this.value?this.value:f.kg("clearedInput","Cleared Input"))}showPreviousValue(){this.history.has(this.value)||this.addToHistory();let e=this.getPreviousValue();e&&(e=e===this.value?this.getPreviousValue():e),e&&(this.value=e,a.h5(this.value))}setPlaceHolder(e){super.setPlaceHolder(e),this.setTooltip(e)}onBlur(){super.onBlur(),this._onDidBlur.fire()}onFocus(){super.onFocus(),this._onDidFocus.fire()}getCurrentValue(){let e=this.history.current();return e||(e=this.history.last(),this.history.next()),e}getPreviousValue(){return this.history.previous()||this.history.first()}getNextValue(){return this.history.next()}}},47625:(e,t,i)=>{"use strict";i.d(t,{x:()=>u,l:()=>d});var s=i(8597),n=i(48196),r=i(42904),o=i(83619),a=i(5662),l=i(10146),c=i(78209);const h=s.$,d={keybindingLabelBackground:void 0,keybindingLabelForeground:void 0,keybindingLabelBorder:void 0,keybindingLabelBottomBorder:void 0,keybindingLabelShadow:void 0};class u extends a.jG{constructor(e,t,i){super(),this.os=t,this.keyElements=new Set,this.options=i||Object.create(null);const o=this.options.keybindingLabelForeground;this.domNode=s.BC(e,h(".monaco-keybinding")),o&&(this.domNode.style.color=o),this.hover=this._register((0,n.i)().setupManagedHover((0,r.nZ)("mouse"),this.domNode,"")),this.didEverRender=!1,e.appendChild(this.domNode)}get element(){return this.domNode}set(e,t){this.didEverRender&&this.keybinding===e&&u.areSame(this.matches,t)||(this.keybinding=e,this.matches=t,this.render())}render(){if(this.clear(),this.keybinding){const e=this.keybinding.getChords();e[0]&&this.renderChord(this.domNode,e[0],this.matches?this.matches.firstPart:null);for(let i=1;i{"use strict";i.d(t,{ur:()=>w,uO:()=>x});var s=i(42731),n=i(8597),r=i(56245),o=i(25154),a=i(31295),l=i(25890),c=i(90766),h=i(58694),d=i(41234),u=i(5662),g=i(92719),p=i(49353);function m(e,t){const i=[];for(const s of t){if(e.start>=s.range.end)continue;if(e.end({range:f(e.range,s),size:e.size}))),o=i.map(((t,i)=>({range:{start:e+i,end:e+i+1},size:t.size})));this.groups=function(...e){return function(e){const t=[];let i=null;for(const s of e){const e=s.range.start,n=s.range.end,r=s.size;i&&r===i.size?i.range.end=n:(i={range:{start:e,end:n},size:r},t.push(i))}return t}(e.reduce(((e,t)=>e.concat(t)),[]))}(n,o,r),this._size=this._paddingTop+this.groups.reduce(((e,t)=>e+t.size*(t.range.end-t.range.start)),0)}get count(){const e=this.groups.length;return e?this.groups[e-1].range.end:0}get size(){return this._size}indexAt(e){if(e<0)return-1;if(e{for(const i of e){this.getRenderer(t).disposeTemplate(i.templateData),i.templateData=null}})),this.cache.clear(),this.transactionNodesPendingRemoval.clear()}getRenderer(e){const t=this.renderers.get(e);if(!t)throw new Error(`No renderer found for ${e}`);return t}}var C=i(64383),b=i(1592),E=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};const S={CurrentDragAndDropData:void 0},y={useShadows:!0,verticalScrollMode:1,setRowLineHeight:!0,setRowHeight:!0,supportDynamicHeights:!1,dnd:{getDragElements:e=>[e],getDragURI:()=>null,onDragStart(){},onDragOver:()=>!1,drop(){},dispose(){}},horizontalScrolling:!1,transformOptimization:!0,alwaysConsumeMouseWheel:!0};class w{constructor(e){this.elements=e}update(){}getData(){return this.elements}}class L{constructor(e){this.elements=e}update(){}getData(){return this.elements}}class R{constructor(){this.types=[],this.files=[]}update(e){if(e.types&&this.types.splice(0,this.types.length,...e.types),e.files){this.files.splice(0,this.files.length);for(let t=0;ti,this.getPosInSet=e?.getPosInSet?e.getPosInSet.bind(e):(e,t)=>t+1,this.getRole=e?.getRole?e.getRole.bind(e):e=>"listitem",this.isChecked=e?.isChecked?e.isChecked.bind(e):e=>{}}}class x{static{this.InstanceCount=0}get contentHeight(){return this.rangeMap.size}get onDidScroll(){return this.scrollableElement.onScroll}get scrollableElementDomNode(){return this.scrollableElement.getDomNode()}get horizontalScrolling(){return this._horizontalScrolling}set horizontalScrolling(e){if(e!==this._horizontalScrolling){if(e&&this.supportDynamicHeights)throw new Error("Horizontal scrolling and dynamic heights not supported simultaneously");if(this._horizontalScrolling=e,this.domNode.classList.toggle("horizontal-scrolling",this._horizontalScrolling),this._horizontalScrolling){for(const e of this.items)this.measureItemWidth(e);this.updateScrollWidth(),this.scrollableElement.setScrollDimensions({width:(0,n.y6)(this.domNode)}),this.rowsContainer.style.width=`${Math.max(this.scrollWidth||0,this.renderWidth)}px`}else this.scrollableElementWidthDelayer.cancel(),this.scrollableElement.setScrollDimensions({width:this.renderWidth,scrollWidth:this.renderWidth}),this.rowsContainer.style.width=""}}constructor(e,t,i,s=y){if(this.virtualDelegate=t,this.domId="list_id_"+ ++x.InstanceCount,this.renderers=new Map,this.renderWidth=0,this._scrollHeight=0,this.scrollableElementUpdateDisposable=null,this.scrollableElementWidthDelayer=new c.ve(50),this.splicing=!1,this.dragOverAnimationStopDisposable=u.jG.None,this.dragOverMouseY=0,this.canDrop=!1,this.currentDragFeedbackDisposable=u.jG.None,this.onDragLeaveTimeout=u.jG.None,this.disposables=new u.Cm,this._onDidChangeContentHeight=new d.vl,this._onDidChangeContentWidth=new d.vl,this.onDidChangeContentHeight=d.Jh.latch(this._onDidChangeContentHeight.event,void 0,this.disposables),this._horizontalScrolling=!1,s.horizontalScrolling&&s.supportDynamicHeights)throw new Error("Horizontal scrolling and dynamic heights not supported simultaneously");this.items=[],this.itemId=0,this.rangeMap=this.createRangeMap(s.paddingTop??0);for(const n of i)this.renderers.set(n.templateId,n);this.cache=this.disposables.add(new v(this.renderers)),this.lastRenderTop=0,this.lastRenderHeight=0,this.domNode=document.createElement("div"),this.domNode.className="monaco-list",this.domNode.classList.add(this.domId),this.domNode.tabIndex=0,this.domNode.classList.toggle("mouse-support","boolean"!==typeof s.mouseSupport||s.mouseSupport),this._horizontalScrolling=s.horizontalScrolling??y.horizontalScrolling,this.domNode.classList.toggle("horizontal-scrolling",this._horizontalScrolling),this.paddingBottom="undefined"===typeof s.paddingBottom?0:s.paddingBottom,this.accessibilityProvider=new T(s.accessibilityProvider),this.rowsContainer=document.createElement("div"),this.rowsContainer.className="monaco-list-rows";(s.transformOptimization??y.transformOptimization)&&(this.rowsContainer.style.transform="translate3d(0px, 0px, 0px)",this.rowsContainer.style.overflow="hidden",this.rowsContainer.style.contain="strict"),this.disposables.add(o.q.addTarget(this.rowsContainer)),this.scrollable=this.disposables.add(new p.yE({forceIntegerValues:!0,smoothScrollDuration:s.smoothScrolling?125:0,scheduleAtNextAnimationFrame:e=>(0,n.PG)((0,n.zk)(this.domNode),e)})),this.scrollableElement=this.disposables.add(new a.oO(this.rowsContainer,{alwaysConsumeMouseWheel:s.alwaysConsumeMouseWheel??y.alwaysConsumeMouseWheel,horizontal:1,vertical:s.verticalScrollMode??y.verticalScrollMode,useShadows:s.useShadows??y.useShadows,mouseWheelScrollSensitivity:s.mouseWheelScrollSensitivity,fastScrollSensitivity:s.fastScrollSensitivity,scrollByPage:s.scrollByPage},this.scrollable)),this.domNode.appendChild(this.scrollableElement.getDomNode()),e.appendChild(this.domNode),this.scrollableElement.onScroll(this.onScroll,this,this.disposables),this.disposables.add((0,n.ko)(this.rowsContainer,o.B.Change,(e=>this.onTouchChange(e)))),this.disposables.add((0,n.ko)(this.scrollableElement.getDomNode(),"scroll",(e=>e.target.scrollTop=0))),this.disposables.add((0,n.ko)(this.domNode,"dragover",(e=>this.onDragOver(this.toDragEvent(e))))),this.disposables.add((0,n.ko)(this.domNode,"drop",(e=>this.onDrop(this.toDragEvent(e))))),this.disposables.add((0,n.ko)(this.domNode,"dragleave",(e=>this.onDragLeave(this.toDragEvent(e))))),this.disposables.add((0,n.ko)(this.domNode,"dragend",(e=>this.onDragEnd(e)))),this.setRowLineHeight=s.setRowLineHeight??y.setRowLineHeight,this.setRowHeight=s.setRowHeight??y.setRowHeight,this.supportDynamicHeights=s.supportDynamicHeights??y.supportDynamicHeights,this.dnd=s.dnd??this.disposables.add(y.dnd),this.layout(s.initialSize?.height,s.initialSize?.width)}updateOptions(e){let t;if(void 0!==e.paddingBottom&&(this.paddingBottom=e.paddingBottom,this.scrollableElement.setScrollDimensions({scrollHeight:this.scrollHeight})),void 0!==e.smoothScrolling&&this.scrollable.setSmoothScrollDuration(e.smoothScrolling?125:0),void 0!==e.horizontalScrolling&&(this.horizontalScrolling=e.horizontalScrolling),void 0!==e.scrollByPage&&(t={...t??{},scrollByPage:e.scrollByPage}),void 0!==e.mouseWheelScrollSensitivity&&(t={...t??{},mouseWheelScrollSensitivity:e.mouseWheelScrollSensitivity}),void 0!==e.fastScrollSensitivity&&(t={...t??{},fastScrollSensitivity:e.fastScrollSensitivity}),t&&this.scrollableElement.updateOptions(t),void 0!==e.paddingTop&&e.paddingTop!==this.rangeMap.paddingTop){const t=this.getRenderRange(this.lastRenderTop,this.lastRenderHeight),i=e.paddingTop-this.rangeMap.paddingTop;this.rangeMap.paddingTop=e.paddingTop,this.render(t,Math.max(0,this.lastRenderTop+i),this.lastRenderHeight,void 0,void 0,!0),this.setScrollTop(this.lastRenderTop),this.eventuallyUpdateScrollDimensions(),this.supportDynamicHeights&&this._rerender(this.lastRenderTop,this.lastRenderHeight)}}createRangeMap(e){return new _(e)}splice(e,t,i=[]){if(this.splicing)throw new Error("Can't run recursive splices.");this.splicing=!0;try{return this._splice(e,t,i)}finally{this.splicing=!1,this._onDidChangeContentHeight.fire(this.contentHeight)}}_splice(e,t,i=[]){const s=this.getRenderRange(this.lastRenderTop,this.lastRenderHeight),n={start:e,end:e+t},r=g.Q.intersect(s,n),o=new Map;for(let u=r.end-1;u>=r.start;u--){const e=this.items[u];if(e.dragStartDisposable.dispose(),e.checkedDisposable.dispose(),e.row){let t=o.get(e.templateId);t||(t=[],o.set(e.templateId,t));const i=this.renderers.get(e.templateId);i&&i.disposeElement&&i.disposeElement(e.element,u,e.row.templateData,e.size),t.unshift(e.row)}e.row=null,e.stale=!0}const a={start:e+t,end:this.items.length},l=g.Q.intersect(a,s),c=g.Q.relativeComplement(a,s),h=i.map((e=>({id:String(this.itemId++),element:e,templateId:this.virtualDelegate.getTemplateId(e),size:this.virtualDelegate.getHeight(e),width:void 0,hasDynamicHeight:!!this.virtualDelegate.hasDynamicHeight&&this.virtualDelegate.hasDynamicHeight(e),lastDynamicHeightWidth:void 0,row:null,uri:void 0,dropTarget:!1,dragStartDisposable:u.jG.None,checkedDisposable:u.jG.None,stale:!1})));let d;0===e&&t>=this.items.length?(this.rangeMap=this.createRangeMap(this.rangeMap.paddingTop),this.rangeMap.splice(0,0,h),d=this.items,this.items=h):(this.rangeMap.splice(e,t,h),d=this.items.splice(e,t,...h));const p=i.length-t,m=this.getRenderRange(this.lastRenderTop,this.lastRenderHeight),_=f(l,p),v=g.Q.intersect(m,_);for(let u=v.start;uf(e,p))),E=[{start:e,end:e+i.length},...b].map((e=>g.Q.intersect(m,e))).reverse();for(const u of E)for(let e=u.end-1;e>=u.start;e--){const t=this.items[e],i=o.get(t.templateId),s=i?.pop();this.insertItemInDOM(e,s)}for(const u of o.values())for(const e of u)this.cache.release(e);return this.eventuallyUpdateScrollDimensions(),this.supportDynamicHeights&&this._rerender(this.scrollTop,this.renderHeight),d.map((e=>e.element))}eventuallyUpdateScrollDimensions(){this._scrollHeight=this.contentHeight,this.rowsContainer.style.height=`${this._scrollHeight}px`,this.scrollableElementUpdateDisposable||(this.scrollableElementUpdateDisposable=(0,n.PG)((0,n.zk)(this.domNode),(()=>{this.scrollableElement.setScrollDimensions({scrollHeight:this.scrollHeight}),this.updateScrollWidth(),this.scrollableElementUpdateDisposable=null})))}eventuallyUpdateScrollWidth(){this.horizontalScrolling?this.scrollableElementWidthDelayer.trigger((()=>this.updateScrollWidth())):this.scrollableElementWidthDelayer.cancel()}updateScrollWidth(){if(!this.horizontalScrolling)return;let e=0;for(const t of this.items)"undefined"!==typeof t.width&&(e=Math.max(e,t.width));this.scrollWidth=e,this.scrollableElement.setScrollDimensions({scrollWidth:0===e?0:e+10}),this._onDidChangeContentWidth.fire(this.scrollWidth)}rerender(){if(this.supportDynamicHeights){for(const e of this.items)e.lastDynamicHeightWidth=void 0;this._rerender(this.lastRenderTop,this.lastRenderHeight)}}get length(){return this.items.length}get renderHeight(){return this.scrollableElement.getScrollDimensions().height}get firstVisibleIndex(){return this.getRenderRange(this.lastRenderTop,this.lastRenderHeight).start}element(e){return this.items[e].element}indexOf(e){return this.items.findIndex((t=>t.element===e))}domElement(e){const t=this.items[e].row;return t&&t.domNode}elementHeight(e){return this.items[e].size}elementTop(e){return this.rangeMap.positionAt(e)}indexAt(e){return this.rangeMap.indexAt(e)}indexAfter(e){return this.rangeMap.indexAfter(e)}layout(e,t){const i={height:"number"===typeof e?e:(0,n.H4)(this.domNode)};this.scrollableElementUpdateDisposable&&(this.scrollableElementUpdateDisposable.dispose(),this.scrollableElementUpdateDisposable=null,i.scrollHeight=this.scrollHeight),this.scrollableElement.setScrollDimensions(i),"undefined"!==typeof t&&(this.renderWidth=t,this.supportDynamicHeights&&this._rerender(this.scrollTop,this.renderHeight)),this.horizontalScrolling&&this.scrollableElement.setScrollDimensions({width:"number"===typeof t?t:(0,n.y6)(this.domNode)})}render(e,t,i,s,n,r=!1){const o=this.getRenderRange(t,i),a=g.Q.relativeComplement(o,e).reverse(),l=g.Q.relativeComplement(e,o);if(r){const t=g.Q.intersect(e,o);for(let e=t.start;e{for(const e of l)for(let t=e.start;t=e.start;t--)this.insertItemInDOM(t)})),void 0!==s&&(this.rowsContainer.style.left=`-${s}px`),this.rowsContainer.style.top=`-${t}px`,this.horizontalScrolling&&void 0!==n&&(this.rowsContainer.style.width=`${Math.max(n,this.renderWidth)}px`),this.lastRenderTop=t,this.lastRenderHeight=i}insertItemInDOM(e,t){const i=this.items[e];if(!i.row)if(t)i.row=t,i.stale=!0;else{const e=this.cache.alloc(i.templateId);i.row=e.row,i.stale||=e.isReusingConnectedDomNode}const s=this.accessibilityProvider.getRole(i.element)||"listitem";i.row.domNode.setAttribute("role",s);const r=this.accessibilityProvider.isChecked(i.element);if("boolean"===typeof r)i.row.domNode.setAttribute("aria-checked",String(!!r));else if(r){const e=e=>i.row.domNode.setAttribute("aria-checked",String(!!e));e(r.value),i.checkedDisposable=r.onDidChange((()=>e(r.value)))}if(i.stale||!i.row.domNode.parentElement){const t=this.items.at(e+1)?.row?.domNode??null;i.row.domNode.parentElement===this.rowsContainer&&i.row.domNode.nextElementSibling===t||this.rowsContainer.insertBefore(i.row.domNode,t),i.stale=!1}this.updateItemInDOM(i,e);const o=this.renderers.get(i.templateId);if(!o)throw new Error(`No renderer found for template id ${i.templateId}`);o?.renderElement(i.element,e,i.row.templateData,i.size);const a=this.dnd.getDragURI(i.element);i.dragStartDisposable.dispose(),i.row.domNode.draggable=!!a,a&&(i.dragStartDisposable=(0,n.ko)(i.row.domNode,"dragstart",(e=>this.onDragStart(i.element,a,e)))),this.horizontalScrolling&&(this.measureItemWidth(i),this.eventuallyUpdateScrollWidth())}measureItemWidth(e){if(!e.row||!e.row.domNode)return;e.row.domNode.style.width="fit-content",e.width=(0,n.y6)(e.row.domNode);const t=(0,n.zk)(e.row.domNode).getComputedStyle(e.row.domNode);t.paddingLeft&&(e.width+=parseFloat(t.paddingLeft)),t.paddingRight&&(e.width+=parseFloat(t.paddingRight)),e.row.domNode.style.width=""}updateItemInDOM(e,t){e.row.domNode.style.top=`${this.elementTop(t)}px`,this.setRowHeight&&(e.row.domNode.style.height=`${e.size}px`),this.setRowLineHeight&&(e.row.domNode.style.lineHeight=`${e.size}px`),e.row.domNode.setAttribute("data-index",`${t}`),e.row.domNode.setAttribute("data-last-element",t===this.length-1?"true":"false"),e.row.domNode.setAttribute("data-parity",t%2===0?"even":"odd"),e.row.domNode.setAttribute("aria-setsize",String(this.accessibilityProvider.getSetSize(e.element,t,this.length))),e.row.domNode.setAttribute("aria-posinset",String(this.accessibilityProvider.getPosInSet(e.element,t))),e.row.domNode.setAttribute("id",this.getElementDomId(t)),e.row.domNode.classList.toggle("drop-target",e.dropTarget)}removeItemFromDOM(e){const t=this.items[e];if(t.dragStartDisposable.dispose(),t.checkedDisposable.dispose(),t.row){const i=this.renderers.get(t.templateId);i&&i.disposeElement&&i.disposeElement(t.element,e,t.row.templateData,t.size),this.cache.release(t.row),t.row=null}this.horizontalScrolling&&this.eventuallyUpdateScrollWidth()}getScrollTop(){return this.scrollableElement.getScrollPosition().scrollTop}setScrollTop(e,t){this.scrollableElementUpdateDisposable&&(this.scrollableElementUpdateDisposable.dispose(),this.scrollableElementUpdateDisposable=null,this.scrollableElement.setScrollDimensions({scrollHeight:this.scrollHeight})),this.scrollableElement.setScrollPosition({scrollTop:e,reuseAnimation:t})}get scrollTop(){return this.getScrollTop()}set scrollTop(e){this.setScrollTop(e)}get scrollHeight(){return this._scrollHeight+(this.horizontalScrolling?10:0)+this.paddingBottom}get onMouseClick(){return d.Jh.map(this.disposables.add(new r.f(this.domNode,"click")).event,(e=>this.toMouseEvent(e)),this.disposables)}get onMouseDblClick(){return d.Jh.map(this.disposables.add(new r.f(this.domNode,"dblclick")).event,(e=>this.toMouseEvent(e)),this.disposables)}get onMouseMiddleClick(){return d.Jh.filter(d.Jh.map(this.disposables.add(new r.f(this.domNode,"auxclick")).event,(e=>this.toMouseEvent(e)),this.disposables),(e=>1===e.browserEvent.button),this.disposables)}get onMouseDown(){return d.Jh.map(this.disposables.add(new r.f(this.domNode,"mousedown")).event,(e=>this.toMouseEvent(e)),this.disposables)}get onMouseOver(){return d.Jh.map(this.disposables.add(new r.f(this.domNode,"mouseover")).event,(e=>this.toMouseEvent(e)),this.disposables)}get onMouseOut(){return d.Jh.map(this.disposables.add(new r.f(this.domNode,"mouseout")).event,(e=>this.toMouseEvent(e)),this.disposables)}get onContextMenu(){return d.Jh.any(d.Jh.map(this.disposables.add(new r.f(this.domNode,"contextmenu")).event,(e=>this.toMouseEvent(e)),this.disposables),d.Jh.map(this.disposables.add(new r.f(this.domNode,o.B.Contextmenu)).event,(e=>this.toGestureEvent(e)),this.disposables))}get onTouchStart(){return d.Jh.map(this.disposables.add(new r.f(this.domNode,"touchstart")).event,(e=>this.toTouchEvent(e)),this.disposables)}get onTap(){return d.Jh.map(this.disposables.add(new r.f(this.rowsContainer,o.B.Tap)).event,(e=>this.toGestureEvent(e)),this.disposables)}toMouseEvent(e){const t=this.getItemIndexFromEventTarget(e.target||null),i="undefined"===typeof t?void 0:this.items[t];return{browserEvent:e,index:t,element:i&&i.element}}toTouchEvent(e){const t=this.getItemIndexFromEventTarget(e.target||null),i="undefined"===typeof t?void 0:this.items[t];return{browserEvent:e,index:t,element:i&&i.element}}toGestureEvent(e){const t=this.getItemIndexFromEventTarget(e.initialTarget||null),i="undefined"===typeof t?void 0:this.items[t];return{browserEvent:e,index:t,element:i&&i.element}}toDragEvent(e){const t=this.getItemIndexFromEventTarget(e.target||null),i="undefined"===typeof t?void 0:this.items[t];return{browserEvent:e,index:t,element:i&&i.element,sector:this.getTargetSector(e,t)}}onScroll(e){try{const t=this.getRenderRange(this.lastRenderTop,this.lastRenderHeight);this.render(t,e.scrollTop,e.height,e.scrollLeft,e.scrollWidth),this.supportDynamicHeights&&this._rerender(e.scrollTop,e.height,e.inSmoothScrolling)}catch(t){throw console.error("Got bad scroll event:",e),t}}onTouchChange(e){e.preventDefault(),e.stopPropagation(),this.scrollTop-=e.translationY}onDragStart(e,t,i){if(!i.dataTransfer)return;const r=this.dnd.getDragElements(e);if(i.dataTransfer.effectAllowed="copyMove",i.dataTransfer.setData(s.t.TEXT,t),i.dataTransfer.setDragImage){let e;this.dnd.getDragLabel&&(e=this.dnd.getDragLabel(r,i)),"undefined"===typeof e&&(e=String(r.length));const t=(0,n.$)(".monaco-drag-image");t.textContent=e;(e=>{for(;e&&!e.classList.contains("monaco-workbench");)e=e.parentElement;return e||this.domNode.ownerDocument})(this.domNode).appendChild(t),i.dataTransfer.setDragImage(t,-10,-10),setTimeout((()=>t.remove()),0)}this.domNode.classList.add("dragging"),this.currentDragData=new w(r),S.CurrentDragAndDropData=new L(r),this.dnd.onDragStart?.(this.currentDragData,i)}onDragOver(e){if(e.browserEvent.preventDefault(),this.onDragLeaveTimeout.dispose(),S.CurrentDragAndDropData&&"vscode-ui"===S.CurrentDragAndDropData.getData())return!1;if(this.setupDragAndDropScrollTopAnimation(e.browserEvent),!e.browserEvent.dataTransfer)return!1;if(!this.currentDragData)if(S.CurrentDragAndDropData)this.currentDragData=S.CurrentDragAndDropData;else{if(!e.browserEvent.dataTransfer.types)return!1;this.currentDragData=new R}const t=this.dnd.onDragOver(this.currentDragData,e.element,e.index,e.sector,e.browserEvent);if(this.canDrop="boolean"===typeof t?t:t.accept,!this.canDrop)return this.currentDragFeedback=void 0,this.currentDragFeedbackDisposable.dispose(),!1;let i;e.browserEvent.dataTransfer.dropEffect="boolean"!==typeof t&&0===t.effect?.type?"copy":"move",i="boolean"!==typeof t&&t.feedback?t.feedback:"undefined"===typeof e.index?[-1]:[e.index],i=(0,l.dM)(i).filter((e=>e>=-1&&ee-t)),i=-1===i[0]?[-1]:i;let s="boolean"!==typeof t&&t.effect&&t.effect.position?t.effect.position:"drop-target";if(n=this.currentDragFeedback,r=i,(Array.isArray(n)&&Array.isArray(r)?(0,l.aI)(n,r):n===r)&&this.currentDragFeedbackPosition===s)return!0;var n,r;if(this.currentDragFeedback=i,this.currentDragFeedbackPosition=s,this.currentDragFeedbackDisposable.dispose(),-1===i[0])this.domNode.classList.add(s),this.rowsContainer.classList.add(s),this.currentDragFeedbackDisposable=(0,u.s)((()=>{this.domNode.classList.remove(s),this.rowsContainer.classList.remove(s)}));else{if(i.length>1&&"drop-target"!==s)throw new Error("Can't use multiple feedbacks with position different than 'over'");"drop-target-after"===s&&i[0]{for(const e of i){const t=this.items[e];t.dropTarget=!1,t.row?.domNode.classList.remove(s)}}))}return!0}onDragLeave(e){this.onDragLeaveTimeout.dispose(),this.onDragLeaveTimeout=(0,c.EQ)((()=>this.clearDragOverFeedback()),100,this.disposables),this.currentDragData&&this.dnd.onDragLeave?.(this.currentDragData,e.element,e.index,e.browserEvent)}onDrop(e){if(!this.canDrop)return;const t=this.currentDragData;this.teardownDragAndDropScrollTopAnimation(),this.clearDragOverFeedback(),this.domNode.classList.remove("dragging"),this.currentDragData=void 0,S.CurrentDragAndDropData=void 0,t&&e.browserEvent.dataTransfer&&(e.browserEvent.preventDefault(),t.update(e.browserEvent.dataTransfer),this.dnd.drop(t,e.element,e.index,e.sector,e.browserEvent))}onDragEnd(e){this.canDrop=!1,this.teardownDragAndDropScrollTopAnimation(),this.clearDragOverFeedback(),this.domNode.classList.remove("dragging"),this.currentDragData=void 0,S.CurrentDragAndDropData=void 0,this.dnd.onDragEnd?.(e)}clearDragOverFeedback(){this.currentDragFeedback=void 0,this.currentDragFeedbackPosition=void 0,this.currentDragFeedbackDisposable.dispose(),this.currentDragFeedbackDisposable=u.jG.None}setupDragAndDropScrollTopAnimation(e){if(!this.dragOverAnimationDisposable){const e=(0,n.cL)(this.domNode).top;this.dragOverAnimationDisposable=(0,n.i0)((0,n.zk)(this.domNode),this.animateDragAndDropScrollTop.bind(this,e))}this.dragOverAnimationStopDisposable.dispose(),this.dragOverAnimationStopDisposable=(0,c.EQ)((()=>{this.dragOverAnimationDisposable&&(this.dragOverAnimationDisposable.dispose(),this.dragOverAnimationDisposable=void 0)}),1e3,this.disposables),this.dragOverMouseY=e.pageY}animateDragAndDropScrollTop(e){if(void 0===this.dragOverMouseY)return;const t=this.dragOverMouseY-e,i=this.renderHeight-35;t<35?this.scrollTop+=Math.max(-14,Math.floor(.3*(t-35))):t>i&&(this.scrollTop+=Math.min(14,Math.floor(.3*(t-i))))}teardownDragAndDropScrollTopAnimation(){this.dragOverAnimationStopDisposable.dispose(),this.dragOverAnimationDisposable&&(this.dragOverAnimationDisposable.dispose(),this.dragOverAnimationDisposable=void 0)}getTargetSector(e,t){if(void 0===t)return;const i=e.offsetY/this.items[t].size,s=Math.floor(i/.25);return(0,b.qE)(s,0,3)}getItemIndexFromEventTarget(e){const t=this.scrollableElement.getDomNode();let i=e;for(;((0,n.sb)(i)||(0,n.xZ)(i))&&i!==this.rowsContainer&&t.contains(i);){const e=i.getAttribute("data-index");if(e){const t=Number(e);if(!isNaN(t))return t}i=i.parentElement}}getRenderRange(e,t){return{start:this.rangeMap.indexAt(e),end:this.rangeMap.indexAfter(e+t-1)}}_rerender(e,t,i){const s=this.getRenderRange(e,t);let n,r;e===this.elementTop(s.start)?(n=s.start,r=0):s.end-s.start>1&&(n=s.start+1,r=this.elementTop(n)-e);let o=0;for(;;){const a=this.getRenderRange(e,t);let l=!1;for(let e=a.start;e=e.start;t--)this.insertItemInDOM(t);for(let e=a.start;e{"use strict";i.d(t,{hb:()=>K,B8:()=>ee,MH:()=>j,_C:()=>b,W0:()=>D,Bm:()=>F,B6:()=>A,b$:()=>O,bm:()=>I,mh:()=>z,tX:()=>V,Es:()=>P,xu:()=>M,bG:()=>Y});var s=i(8597),n=i(56245),r=i(72962),o=i(25154),a=i(11007);class l{constructor(e){this.spliceables=e}splice(e,t,i){this.spliceables.forEach((s=>s.splice(e,t,i)))}}var c=i(25890),h=i(90766),d=i(47661),u=i(58694),g=i(41234),p=i(26690),m=i(5662),f=i(1592),_=i(98067),v=i(631);i(48215);class C extends Error{constructor(e,t){super(`ListError [${e}] ${t}`)}}var b,E,S=i(66700),y=i(47358),w=i(31308),L=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};class R{constructor(e){this.trait=e,this.renderedElements=[]}get templateId(){return`template:${this.trait.name}`}renderTemplate(e){return e}renderElement(e,t,i){const s=this.renderedElements.findIndex((e=>e.templateData===i));if(s>=0){const e=this.renderedElements[s];this.trait.unrender(i),e.index=t}else{const e={index:t,templateData:i};this.renderedElements.push(e)}this.trait.renderIndex(t,i)}splice(e,t,i){const s=[];for(const n of this.renderedElements)n.index=e+t&&s.push({index:n.index+i-t,templateData:n.templateData});this.renderedElements=s}renderIndexes(e){for(const{index:t,templateData:i}of this.renderedElements)e.indexOf(t)>-1&&this.trait.renderIndex(t,i)}disposeTemplate(e){const t=this.renderedElements.findIndex((t=>t.templateData===e));t<0||this.renderedElements.splice(t,1)}}class T{get name(){return this._trait}get renderer(){return new R(this)}constructor(e){this._trait=e,this.indexes=[],this.sortedIndexes=[],this._onChange=new g.vl,this.onChange=this._onChange.event}splice(e,t,i){const s=i.length-t,n=e+t,r=[];let o=0;for(;o=n;)r.push(this.sortedIndexes[o++]+s);this.renderer.splice(e,t,i.length),this._set(r,r)}renderIndex(e,t){t.classList.toggle(this._trait,this.contains(e))}unrender(e){e.classList.remove(this._trait)}set(e,t){return this._set(e,[...e].sort(Q),t)}_set(e,t,i){const s=this.indexes,n=this.sortedIndexes;this.indexes=e,this.sortedIndexes=t;const r=$(n,e);return this.renderer.renderIndexes(r),this._onChange.fire({indexes:e,browserEvent:i}),s}get(){return this.indexes}contains(e){return(0,c.El)(this.sortedIndexes,e,Q)>=0}dispose(){(0,m.AS)(this._onChange)}}L([u.B],T.prototype,"renderer",null);class x extends T{constructor(e){super("selected"),this.setAriaSelected=e}renderIndex(e,t){super.renderIndex(e,t),this.setAriaSelected&&(this.contains(e)?t.setAttribute("aria-selected","true"):t.setAttribute("aria-selected","false"))}}class k{constructor(e,t,i){this.trait=e,this.view=t,this.identityProvider=i}splice(e,t,i){if(!this.identityProvider)return this.trait.splice(e,t,new Array(i.length).fill(!1));const s=this.trait.get().map((e=>this.identityProvider.getId(this.view.element(e)).toString()));if(0===s.length)return this.trait.splice(e,t,new Array(i.length).fill(!1));const n=new Set(s),r=i.map((e=>n.has(this.identityProvider.getId(e).toString())));this.trait.splice(e,t,r)}}function A(e){return"INPUT"===e.tagName||"TEXTAREA"===e.tagName}function N(e,t){return!!e.classList.contains(t)||!e.classList.contains("monaco-list")&&(!!e.parentElement&&N(e.parentElement,t))}function I(e){return N(e,"monaco-editor")}function O(e){return N(e,"monaco-custom-toggle")}function D(e){return N(e,"action-item")}function M(e){return N(e,"monaco-tree-sticky-row")}function P(e){return e.classList.contains("monaco-tree-sticky-container")}function F(e){return!!("A"===e.tagName&&e.classList.contains("monaco-button")||"DIV"===e.tagName&&e.classList.contains("monaco-button-dropdown"))||!e.classList.contains("monaco-list")&&(!!e.parentElement&&F(e.parentElement))}class U{get onKeyDown(){return g.Jh.chain(this.disposables.add(new n.f(this.view.domNode,"keydown")).event,(e=>e.filter((e=>!A(e.target))).map((e=>new r.Z(e)))))}constructor(e,t,i){this.list=e,this.view=t,this.disposables=new m.Cm,this.multipleSelectionDisposables=new m.Cm,this.multipleSelectionSupport=i.multipleSelectionSupport,this.disposables.add(this.onKeyDown((e=>{switch(e.keyCode){case 3:return this.onEnter(e);case 16:return this.onUpArrow(e);case 18:return this.onDownArrow(e);case 11:return this.onPageUpArrow(e);case 12:return this.onPageDownArrow(e);case 9:return this.onEscape(e);case 31:this.multipleSelectionSupport&&(_.zx?e.metaKey:e.ctrlKey)&&this.onCtrlA(e)}})))}updateOptions(e){void 0!==e.multipleSelectionSupport&&(this.multipleSelectionSupport=e.multipleSelectionSupport)}onEnter(e){e.preventDefault(),e.stopPropagation(),this.list.setSelection(this.list.getFocus(),e.browserEvent)}onUpArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusPrevious(1,!1,e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onDownArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusNext(1,!1,e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onPageUpArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusPreviousPage(e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onPageDownArrow(e){e.preventDefault(),e.stopPropagation(),this.list.focusNextPage(e.browserEvent);const t=this.list.getFocus()[0];this.list.setAnchor(t),this.list.reveal(t),this.view.domNode.focus()}onCtrlA(e){e.preventDefault(),e.stopPropagation(),this.list.setSelection((0,c.y1)(this.list.length),e.browserEvent),this.list.setAnchor(void 0),this.view.domNode.focus()}onEscape(e){this.list.getSelection().length&&(e.preventDefault(),e.stopPropagation(),this.list.setSelection([],e.browserEvent),this.list.setAnchor(void 0),this.view.domNode.focus())}dispose(){this.disposables.dispose(),this.multipleSelectionDisposables.dispose()}}L([u.B],U.prototype,"onKeyDown",null),function(e){e[e.Automatic=0]="Automatic",e[e.Trigger=1]="Trigger"}(b||(b={})),function(e){e[e.Idle=0]="Idle",e[e.Typing=1]="Typing"}(E||(E={}));const H=new class{mightProducePrintableCharacter(e){return!(e.ctrlKey||e.metaKey||e.altKey)&&(e.keyCode>=31&&e.keyCode<=56||e.keyCode>=21&&e.keyCode<=30||e.keyCode>=98&&e.keyCode<=107||e.keyCode>=85&&e.keyCode<=95)}};class B{constructor(e,t,i,s,n){this.list=e,this.view=t,this.keyboardNavigationLabelProvider=i,this.keyboardNavigationEventFilter=s,this.delegate=n,this.enabled=!1,this.state=E.Idle,this.mode=b.Automatic,this.triggered=!1,this.previouslyFocused=-1,this.enabledDisposables=new m.Cm,this.disposables=new m.Cm,this.updateOptions(e.options)}updateOptions(e){e.typeNavigationEnabled??1?this.enable():this.disable(),this.mode=e.typeNavigationMode??b.Automatic}enable(){if(this.enabled)return;let e=!1;const t=g.Jh.chain(this.enabledDisposables.add(new n.f(this.view.domNode,"keydown")).event,(t=>t.filter((e=>!A(e.target))).filter((()=>this.mode===b.Automatic||this.triggered)).map((e=>new r.Z(e))).filter((t=>e||this.keyboardNavigationEventFilter(t))).filter((e=>this.delegate.mightProducePrintableCharacter(e))).forEach((e=>s.fs.stop(e,!0))).map((e=>e.browserEvent.key)))),i=g.Jh.debounce(t,(()=>null),800,void 0,void 0,void 0,this.enabledDisposables);g.Jh.reduce(g.Jh.any(t,i),((e,t)=>null===t?null:(e||"")+t),void 0,this.enabledDisposables)(this.onInput,this,this.enabledDisposables),i(this.onClear,this,this.enabledDisposables),t((()=>e=!0),void 0,this.enabledDisposables),i((()=>e=!1),void 0,this.enabledDisposables),this.enabled=!0,this.triggered=!1}disable(){this.enabled&&(this.enabledDisposables.clear(),this.enabled=!1,this.triggered=!1)}onClear(){const e=this.list.getFocus();if(e.length>0&&e[0]===this.previouslyFocused){const t=this.list.options.accessibilityProvider?.getAriaLabel(this.list.element(e[0]));"string"===typeof t?(0,a.xE)(t):t&&(0,a.xE)(t.get())}this.previouslyFocused=-1}onInput(e){if(!e)return this.state=E.Idle,void(this.triggered=!1);const t=this.list.getFocus(),i=t.length>0?t[0]:0,s=this.state===E.Idle?1:0;this.state=E.Typing;for(let n=0;n1&&1===s.length)return this.previouslyFocused=i,this.list.setFocus([t]),void this.list.reveal(t)}}}else if("undefined"===typeof o||(0,p.WP)(e,o))return this.previouslyFocused=i,this.list.setFocus([t]),void this.list.reveal(t)}}dispose(){this.disable(),this.enabledDisposables.dispose(),this.disposables.dispose()}}class W{constructor(e,t){this.list=e,this.view=t,this.disposables=new m.Cm;const i=g.Jh.chain(this.disposables.add(new n.f(t.domNode,"keydown")).event,(e=>e.filter((e=>!A(e.target))).map((e=>new r.Z(e)))));g.Jh.chain(i,(e=>e.filter((e=>2===e.keyCode&&!e.ctrlKey&&!e.metaKey&&!e.shiftKey&&!e.altKey))))(this.onTab,this,this.disposables)}onTab(e){if(e.target!==this.view.domNode)return;const t=this.list.getFocus();if(0===t.length)return;const i=this.view.domElement(t[0]);if(!i)return;const n=i.querySelector("[tabIndex]");if(!n||!(0,s.sb)(n)||-1===n.tabIndex)return;const r=(0,s.zk)(n).getComputedStyle(n);"hidden"!==r.visibility&&"none"!==r.display&&(e.preventDefault(),e.stopPropagation(),n.focus())}dispose(){this.disposables.dispose()}}function V(e){return _.zx?e.browserEvent.metaKey:e.browserEvent.ctrlKey}function z(e){return e.browserEvent.shiftKey}const G={isSelectionSingleChangeEvent:V,isSelectionRangeChangeEvent:z};class j{constructor(e){this.list=e,this.disposables=new m.Cm,this._onPointer=new g.vl,this.onPointer=this._onPointer.event,!1!==e.options.multipleSelectionSupport&&(this.multipleSelectionController=this.list.options.multipleSelectionController||G),this.mouseSupport="undefined"===typeof e.options.mouseSupport||!!e.options.mouseSupport,this.mouseSupport&&(e.onMouseDown(this.onMouseDown,this,this.disposables),e.onContextMenu(this.onContextMenu,this,this.disposables),e.onMouseDblClick(this.onDoubleClick,this,this.disposables),e.onTouchStart(this.onMouseDown,this,this.disposables),this.disposables.add(o.q.addTarget(e.getHTMLElement()))),g.Jh.any(e.onMouseClick,e.onMouseMiddleClick,e.onTap)(this.onViewPointer,this,this.disposables)}updateOptions(e){void 0!==e.multipleSelectionSupport&&(this.multipleSelectionController=void 0,e.multipleSelectionSupport&&(this.multipleSelectionController=this.list.options.multipleSelectionController||G))}isSelectionSingleChangeEvent(e){return!!this.multipleSelectionController&&this.multipleSelectionController.isSelectionSingleChangeEvent(e)}isSelectionRangeChangeEvent(e){return!!this.multipleSelectionController&&this.multipleSelectionController.isSelectionRangeChangeEvent(e)}isSelectionChangeEvent(e){return this.isSelectionSingleChangeEvent(e)||this.isSelectionRangeChangeEvent(e)}onMouseDown(e){I(e.browserEvent.target)||(0,s.bq)()!==e.browserEvent.target&&this.list.domFocus()}onContextMenu(e){if(A(e.browserEvent.target)||I(e.browserEvent.target))return;const t="undefined"===typeof e.index?[]:[e.index];this.list.setFocus(t,e.browserEvent)}onViewPointer(e){if(!this.mouseSupport)return;if(A(e.browserEvent.target)||I(e.browserEvent.target))return;if(e.browserEvent.isHandledByList)return;e.browserEvent.isHandledByList=!0;const t=e.index;return"undefined"===typeof t?(this.list.setFocus([],e.browserEvent),this.list.setSelection([],e.browserEvent),void this.list.setAnchor(void 0)):this.isSelectionChangeEvent(e)?this.changeSelection(e):(this.list.setFocus([t],e.browserEvent),this.list.setAnchor(t),i=e.browserEvent,(0,s.Er)(i)&&2===i.button||this.list.setSelection([t],e.browserEvent),void this._onPointer.fire(e));var i}onDoubleClick(e){if(A(e.browserEvent.target)||I(e.browserEvent.target))return;if(this.isSelectionChangeEvent(e))return;if(e.browserEvent.isHandledByList)return;e.browserEvent.isHandledByList=!0;const t=this.list.getFocus();this.list.setSelection(t,e.browserEvent)}changeSelection(e){const t=e.index;let i=this.list.getAnchor();if(this.isSelectionRangeChangeEvent(e)){if("undefined"===typeof i){i=this.list.getFocus()[0]??t,this.list.setAnchor(i)}const s=Math.min(i,t),n=Math.max(i,t),r=(0,c.y1)(s,n+1),o=this.list.getSelection(),a=function(e,t){const i=e.indexOf(t);if(-1===i)return[];const s=[];let n=i-1;for(;n>=0&&e[n]===t-(i-n);)s.push(e[n--]);s.reverse(),n=i;for(;n=e.length)i.push(t[n++]);else if(n>=t.length)i.push(e[s++]);else{if(e[s]===t[n]){s++,n++;continue}e[s]e!==t));this.list.setFocus([t]),this.list.setAnchor(t),i.length===s.length?this.list.setSelection([...s,t],e.browserEvent):this.list.setSelection(s,e.browserEvent)}}dispose(){this.disposables.dispose()}}class K{constructor(e,t){this.styleElement=e,this.selectorSuffix=t}style(e){const t=this.selectorSuffix&&`.${this.selectorSuffix}`,i=[];e.listBackground&&i.push(`.monaco-list${t} .monaco-list-rows { background: ${e.listBackground}; }`),e.listFocusBackground&&(i.push(`.monaco-list${t}:focus .monaco-list-row.focused { background-color: ${e.listFocusBackground}; }`),i.push(`.monaco-list${t}:focus .monaco-list-row.focused:hover { background-color: ${e.listFocusBackground}; }`)),e.listFocusForeground&&i.push(`.monaco-list${t}:focus .monaco-list-row.focused { color: ${e.listFocusForeground}; }`),e.listActiveSelectionBackground&&(i.push(`.monaco-list${t}:focus .monaco-list-row.selected { background-color: ${e.listActiveSelectionBackground}; }`),i.push(`.monaco-list${t}:focus .monaco-list-row.selected:hover { background-color: ${e.listActiveSelectionBackground}; }`)),e.listActiveSelectionForeground&&i.push(`.monaco-list${t}:focus .monaco-list-row.selected { color: ${e.listActiveSelectionForeground}; }`),e.listActiveSelectionIconForeground&&i.push(`.monaco-list${t}:focus .monaco-list-row.selected .codicon { color: ${e.listActiveSelectionIconForeground}; }`),e.listFocusAndSelectionBackground&&i.push(`\n\t\t\t\t.monaco-drag-image,\n\t\t\t\t.monaco-list${t}:focus .monaco-list-row.selected.focused { background-color: ${e.listFocusAndSelectionBackground}; }\n\t\t\t`),e.listFocusAndSelectionForeground&&i.push(`\n\t\t\t\t.monaco-drag-image,\n\t\t\t\t.monaco-list${t}:focus .monaco-list-row.selected.focused { color: ${e.listFocusAndSelectionForeground}; }\n\t\t\t`),e.listInactiveFocusForeground&&(i.push(`.monaco-list${t} .monaco-list-row.focused { color: ${e.listInactiveFocusForeground}; }`),i.push(`.monaco-list${t} .monaco-list-row.focused:hover { color: ${e.listInactiveFocusForeground}; }`)),e.listInactiveSelectionIconForeground&&i.push(`.monaco-list${t} .monaco-list-row.focused .codicon { color: ${e.listInactiveSelectionIconForeground}; }`),e.listInactiveFocusBackground&&(i.push(`.monaco-list${t} .monaco-list-row.focused { background-color: ${e.listInactiveFocusBackground}; }`),i.push(`.monaco-list${t} .monaco-list-row.focused:hover { background-color: ${e.listInactiveFocusBackground}; }`)),e.listInactiveSelectionBackground&&(i.push(`.monaco-list${t} .monaco-list-row.selected { background-color: ${e.listInactiveSelectionBackground}; }`),i.push(`.monaco-list${t} .monaco-list-row.selected:hover { background-color: ${e.listInactiveSelectionBackground}; }`)),e.listInactiveSelectionForeground&&i.push(`.monaco-list${t} .monaco-list-row.selected { color: ${e.listInactiveSelectionForeground}; }`),e.listHoverBackground&&i.push(`.monaco-list${t}:not(.drop-target):not(.dragging) .monaco-list-row:hover:not(.selected):not(.focused) { background-color: ${e.listHoverBackground}; }`),e.listHoverForeground&&i.push(`.monaco-list${t}:not(.drop-target):not(.dragging) .monaco-list-row:hover:not(.selected):not(.focused) { color: ${e.listHoverForeground}; }`);const n=(0,s.gI)(e.listFocusAndSelectionOutline,(0,s.gI)(e.listSelectionOutline,e.listFocusOutline??""));n&&i.push(`.monaco-list${t}:focus .monaco-list-row.focused.selected { outline: 1px solid ${n}; outline-offset: -1px;}`),e.listFocusOutline&&i.push(`\n\t\t\t\t.monaco-drag-image,\n\t\t\t\t.monaco-list${t}:focus .monaco-list-row.focused { outline: 1px solid ${e.listFocusOutline}; outline-offset: -1px; }\n\t\t\t\t.monaco-workbench.context-menu-visible .monaco-list${t}.last-focused .monaco-list-row.focused { outline: 1px solid ${e.listFocusOutline}; outline-offset: -1px; }\n\t\t\t`);const r=(0,s.gI)(e.listSelectionOutline,e.listInactiveFocusOutline??"");r&&i.push(`.monaco-list${t} .monaco-list-row.focused.selected { outline: 1px dotted ${r}; outline-offset: -1px; }`),e.listSelectionOutline&&i.push(`.monaco-list${t} .monaco-list-row.selected { outline: 1px dotted ${e.listSelectionOutline}; outline-offset: -1px; }`),e.listInactiveFocusOutline&&i.push(`.monaco-list${t} .monaco-list-row.focused { outline: 1px dotted ${e.listInactiveFocusOutline}; outline-offset: -1px; }`),e.listHoverOutline&&i.push(`.monaco-list${t} .monaco-list-row:hover { outline: 1px dashed ${e.listHoverOutline}; outline-offset: -1px; }`),e.listDropOverBackground&&i.push(`\n\t\t\t\t.monaco-list${t}.drop-target,\n\t\t\t\t.monaco-list${t} .monaco-list-rows.drop-target,\n\t\t\t\t.monaco-list${t} .monaco-list-row.drop-target { background-color: ${e.listDropOverBackground} !important; color: inherit !important; }\n\t\t\t`),e.listDropBetweenBackground&&(i.push(`\n\t\t\t.monaco-list${t} .monaco-list-rows.drop-target-before .monaco-list-row:first-child::before,\n\t\t\t.monaco-list${t} .monaco-list-row.drop-target-before::before {\n\t\t\t\tcontent: ""; position: absolute; top: 0px; left: 0px; width: 100%; height: 1px;\n\t\t\t\tbackground-color: ${e.listDropBetweenBackground};\n\t\t\t}`),i.push(`\n\t\t\t.monaco-list${t} .monaco-list-rows.drop-target-after .monaco-list-row:last-child::after,\n\t\t\t.monaco-list${t} .monaco-list-row.drop-target-after::after {\n\t\t\t\tcontent: ""; position: absolute; bottom: 0px; left: 0px; width: 100%; height: 1px;\n\t\t\t\tbackground-color: ${e.listDropBetweenBackground};\n\t\t\t}`)),e.tableColumnsBorder&&i.push(`\n\t\t\t\t.monaco-table > .monaco-split-view2,\n\t\t\t\t.monaco-table > .monaco-split-view2 .monaco-sash.vertical::before,\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table:hover > .monaco-split-view2,\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table:hover > .monaco-split-view2 .monaco-sash.vertical::before {\n\t\t\t\t\tborder-color: ${e.tableColumnsBorder};\n\t\t\t\t}\n\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table > .monaco-split-view2,\n\t\t\t\t.monaco-workbench:not(.reduce-motion) .monaco-table > .monaco-split-view2 .monaco-sash.vertical::before {\n\t\t\t\t\tborder-color: transparent;\n\t\t\t\t}\n\t\t\t`),e.tableOddRowsBackgroundColor&&i.push(`\n\t\t\t\t.monaco-table .monaco-list-row[data-parity=odd]:not(.focused):not(.selected):not(:hover) .monaco-table-tr,\n\t\t\t\t.monaco-table .monaco-list:not(:focus) .monaco-list-row[data-parity=odd].focused:not(.selected):not(:hover) .monaco-table-tr,\n\t\t\t\t.monaco-table .monaco-list:not(.focused) .monaco-list-row[data-parity=odd].focused:not(.selected):not(:hover) .monaco-table-tr {\n\t\t\t\t\tbackground-color: ${e.tableOddRowsBackgroundColor};\n\t\t\t\t}\n\t\t\t`),this.styleElement.textContent=i.join("\n")}}const Y={listFocusBackground:"#7FB0D0",listActiveSelectionBackground:"#0E639C",listActiveSelectionForeground:"#FFFFFF",listActiveSelectionIconForeground:"#FFFFFF",listFocusAndSelectionOutline:"#90C2F9",listFocusAndSelectionBackground:"#094771",listFocusAndSelectionForeground:"#FFFFFF",listInactiveSelectionBackground:"#3F3F46",listInactiveSelectionIconForeground:"#FFFFFF",listHoverBackground:"#2A2D2E",listDropOverBackground:"#383B3D",listDropBetweenBackground:"#EEEEEE",treeIndentGuidesStroke:"#a9a9a9",treeInactiveIndentGuidesStroke:d.Q1.fromHex("#a9a9a9").transparent(.4).toString(),tableColumnsBorder:d.Q1.fromHex("#cccccc").transparent(.2).toString(),tableOddRowsBackgroundColor:d.Q1.fromHex("#cccccc").transparent(.04).toString(),listBackground:void 0,listFocusForeground:void 0,listInactiveSelectionForeground:void 0,listInactiveFocusForeground:void 0,listInactiveFocusBackground:void 0,listHoverForeground:void 0,listFocusOutline:void 0,listInactiveFocusOutline:void 0,listSelectionOutline:void 0,listHoverOutline:void 0,treeStickyScrollBackground:void 0,treeStickyScrollBorder:void 0,treeStickyScrollShadow:void 0},q={keyboardSupport:!0,mouseSupport:!0,multipleSelectionSupport:!0,dnd:{getDragURI:()=>null,onDragStart(){},onDragOver:()=>!1,drop(){},dispose(){}}};function $(e,t){const i=[];let s=0,n=0;for(;s=e.length)i.push(t[n++]);else if(n>=t.length)i.push(e[s++]);else{if(e[s]===t[n]){i.push(e[s]),s++,n++;continue}e[s]e-t;class X{constructor(e,t){this._templateId=e,this.renderers=t}get templateId(){return this._templateId}renderTemplate(e){return this.renderers.map((t=>t.renderTemplate(e)))}renderElement(e,t,i,s){let n=0;for(const r of this.renderers)r.renderElement(e,t,i[n++],s)}disposeElement(e,t,i,s){let n=0;for(const r of this.renderers)r.disposeElement?.(e,t,i[n],s),n+=1}disposeTemplate(e){let t=0;for(const i of this.renderers)i.disposeTemplate(e[t++])}}class Z{constructor(e){this.accessibilityProvider=e,this.templateId="a18n"}renderTemplate(e){return{container:e,disposables:new m.Cm}}renderElement(e,t,i){const s=this.accessibilityProvider.getAriaLabel(e),n=s&&"string"!==typeof s?s:(0,w.lk)(s);i.disposables.add((0,w.fm)((e=>{this.setAriaLabel(e.readObservable(n),i.container)})));const r=this.accessibilityProvider.getAriaLevel&&this.accessibilityProvider.getAriaLevel(e);"number"===typeof r?i.container.setAttribute("aria-level",`${r}`):i.container.removeAttribute("aria-level")}setAriaLabel(e,t){e?t.setAttribute("aria-label",e):t.removeAttribute("aria-label")}disposeElement(e,t,i,s){i.disposables.clear()}disposeTemplate(e){e.disposables.dispose()}}class J{constructor(e,t){this.list=e,this.dnd=t}getDragElements(e){const t=this.list.getSelectedElements();return t.indexOf(e)>-1?t:[e]}getDragURI(e){return this.dnd.getDragURI(e)}getDragLabel(e,t){if(this.dnd.getDragLabel)return this.dnd.getDragLabel(e,t)}onDragStart(e,t){this.dnd.onDragStart?.(e,t)}onDragOver(e,t,i,s,n){return this.dnd.onDragOver(e,t,i,s,n)}onDragLeave(e,t,i,s){this.dnd.onDragLeave?.(e,t,i,s)}onDragEnd(e){this.dnd.onDragEnd?.(e)}drop(e,t,i,s,n){this.dnd.drop(e,t,i,s,n)}dispose(){this.dnd.dispose()}}class ee{get onDidChangeFocus(){return g.Jh.map(this.eventBufferer.wrapEvent(this.focus.onChange),(e=>this.toListEvent(e)),this.disposables)}get onDidChangeSelection(){return g.Jh.map(this.eventBufferer.wrapEvent(this.selection.onChange),(e=>this.toListEvent(e)),this.disposables)}get domId(){return this.view.domId}get onDidScroll(){return this.view.onDidScroll}get onMouseClick(){return this.view.onMouseClick}get onMouseDblClick(){return this.view.onMouseDblClick}get onMouseMiddleClick(){return this.view.onMouseMiddleClick}get onPointer(){return this.mouseController.onPointer}get onMouseDown(){return this.view.onMouseDown}get onMouseOver(){return this.view.onMouseOver}get onMouseOut(){return this.view.onMouseOut}get onTouchStart(){return this.view.onTouchStart}get onTap(){return this.view.onTap}get onContextMenu(){let e=!1;const t=g.Jh.chain(this.disposables.add(new n.f(this.view.domNode,"keydown")).event,(t=>t.map((e=>new r.Z(e))).filter((t=>e=58===t.keyCode||t.shiftKey&&68===t.keyCode)).map((e=>s.fs.stop(e,!0))).filter((()=>!1)))),i=g.Jh.chain(this.disposables.add(new n.f(this.view.domNode,"keyup")).event,(t=>t.forEach((()=>e=!1)).map((e=>new r.Z(e))).filter((e=>58===e.keyCode||e.shiftKey&&68===e.keyCode)).map((e=>s.fs.stop(e,!0))).map((({browserEvent:e})=>{const t=this.getFocus(),i=t.length?t[0]:void 0;return{index:i,element:"undefined"!==typeof i?this.view.element(i):void 0,anchor:"undefined"!==typeof i?this.view.domElement(i):this.view.domNode,browserEvent:e}})))),o=g.Jh.chain(this.view.onContextMenu,(t=>t.filter((t=>!e)).map((({element:e,index:t,browserEvent:i})=>({element:e,index:t,anchor:new y.P((0,s.zk)(this.view.domNode),i),browserEvent:i})))));return g.Jh.any(t,i,o)}get onKeyDown(){return this.disposables.add(new n.f(this.view.domNode,"keydown")).event}get onDidFocus(){return g.Jh.signal(this.disposables.add(new n.f(this.view.domNode,"focus",!0)).event)}get onDidBlur(){return g.Jh.signal(this.disposables.add(new n.f(this.view.domNode,"blur",!0)).event)}constructor(e,t,i,n,r=q){this.user=e,this._options=r,this.focus=new T("focused"),this.anchor=new T("anchor"),this.eventBufferer=new g.at,this._ariaLabel="",this.disposables=new m.Cm,this._onDidDispose=new g.vl,this.onDidDispose=this._onDidDispose.event;const o=this._options.accessibilityProvider&&this._options.accessibilityProvider.getWidgetRole?this._options.accessibilityProvider?.getWidgetRole():"list";this.selection=new x("listbox"!==o);const a=[this.focus.renderer,this.selection.renderer];this.accessibilityProvider=r.accessibilityProvider,this.accessibilityProvider&&(a.push(new Z(this.accessibilityProvider)),this.accessibilityProvider.onDidChangeActiveDescendant?.(this.onDidChangeActiveDescendant,this,this.disposables)),n=n.map((e=>new X(e.templateId,[...a,e])));const c={...r,dnd:r.dnd&&new J(this,r.dnd)};if(this.view=this.createListView(t,i,n,c),this.view.domNode.setAttribute("role",o),r.styleController)this.styleController=r.styleController(this.view.domId);else{const e=(0,s.li)(this.view.domNode);this.styleController=new K(e,this.view.domId)}if(this.spliceable=new l([new k(this.focus,this.view,r.identityProvider),new k(this.selection,this.view,r.identityProvider),new k(this.anchor,this.view,r.identityProvider),this.view]),this.disposables.add(this.focus),this.disposables.add(this.selection),this.disposables.add(this.anchor),this.disposables.add(this.view),this.disposables.add(this._onDidDispose),this.disposables.add(new W(this,this.view)),("boolean"!==typeof r.keyboardSupport||r.keyboardSupport)&&(this.keyboardController=new U(this,this.view,r),this.disposables.add(this.keyboardController)),r.keyboardNavigationLabelProvider){const e=r.keyboardNavigationDelegate||H;this.typeNavigationController=new B(this,this.view,r.keyboardNavigationLabelProvider,r.keyboardNavigationEventFilter??(()=>!0),e),this.disposables.add(this.typeNavigationController)}this.mouseController=this.createMouseController(r),this.disposables.add(this.mouseController),this.onDidChangeFocus(this._onFocusChange,this,this.disposables),this.onDidChangeSelection(this._onSelectionChange,this,this.disposables),this.accessibilityProvider&&(this.ariaLabel=this.accessibilityProvider.getWidgetAriaLabel()),!1!==this._options.multipleSelectionSupport&&this.view.domNode.setAttribute("aria-multiselectable","true")}createListView(e,t,i,s){return new S.uO(e,t,i,s)}createMouseController(e){return new j(this)}updateOptions(e={}){this._options={...this._options,...e},this.typeNavigationController?.updateOptions(this._options),void 0!==this._options.multipleSelectionController&&(this._options.multipleSelectionSupport?this.view.domNode.setAttribute("aria-multiselectable","true"):this.view.domNode.removeAttribute("aria-multiselectable")),this.mouseController.updateOptions(e),this.keyboardController?.updateOptions(e),this.view.updateOptions(e)}get options(){return this._options}splice(e,t,i=[]){if(e<0||e>this.view.length)throw new C(this.user,`Invalid start index: ${e}`);if(t<0)throw new C(this.user,`Invalid delete count: ${t}`);0===t&&0===i.length||this.eventBufferer.bufferEvents((()=>this.spliceable.splice(e,t,i)))}rerender(){this.view.rerender()}element(e){return this.view.element(e)}indexOf(e){return this.view.indexOf(e)}indexAt(e){return this.view.indexAt(e)}get length(){return this.view.length}get contentHeight(){return this.view.contentHeight}get onDidChangeContentHeight(){return this.view.onDidChangeContentHeight}get scrollTop(){return this.view.getScrollTop()}set scrollTop(e){this.view.setScrollTop(e)}get scrollHeight(){return this.view.scrollHeight}get renderHeight(){return this.view.renderHeight}get firstVisibleIndex(){return this.view.firstVisibleIndex}get ariaLabel(){return this._ariaLabel}set ariaLabel(e){this._ariaLabel=e,this.view.domNode.setAttribute("aria-label",e)}domFocus(){this.view.domNode.focus({preventScroll:!0})}layout(e,t){this.view.layout(e,t)}setSelection(e,t){for(const i of e)if(i<0||i>=this.length)throw new C(this.user,`Invalid index ${i}`);this.selection.set(e,t)}getSelection(){return this.selection.get()}getSelectedElements(){return this.getSelection().map((e=>this.view.element(e)))}setAnchor(e){if("undefined"!==typeof e){if(e<0||e>=this.length)throw new C(this.user,`Invalid index ${e}`);this.anchor.set([e])}else this.anchor.set([])}getAnchor(){return(0,c.Fy)(this.anchor.get(),void 0)}getAnchorElement(){const e=this.getAnchor();return"undefined"===typeof e?void 0:this.element(e)}setFocus(e,t){for(const i of e)if(i<0||i>=this.length)throw new C(this.user,`Invalid index ${i}`);this.focus.set(e,t)}focusNext(e=1,t=!1,i,s){if(0===this.length)return;const n=this.focus.get(),r=this.findNextIndex(n.length>0?n[0]+e:0,t,s);r>-1&&this.setFocus([r],i)}focusPrevious(e=1,t=!1,i,s){if(0===this.length)return;const n=this.focus.get(),r=this.findPreviousIndex(n.length>0?n[0]-e:0,t,s);r>-1&&this.setFocus([r],i)}async focusNextPage(e,t){let i=this.view.indexAt(this.view.getScrollTop()+this.view.renderHeight);i=0===i?0:i-1;const s=this.getFocus()[0];if(s!==i&&(void 0===s||i>s)){const n=this.findPreviousIndex(i,!1,t);n>-1&&s!==n?this.setFocus([n],e):this.setFocus([i],e)}else{const n=this.view.getScrollTop();let r=n+this.view.renderHeight;i>s&&(r-=this.view.elementHeight(i)),this.view.setScrollTop(r),this.view.getScrollTop()!==n&&(this.setFocus([]),await(0,h.wR)(0),await this.focusNextPage(e,t))}}async focusPreviousPage(e,t,i=()=>0){let s;const n=i(),r=this.view.getScrollTop()+n;s=0===r?this.view.indexAt(r):this.view.indexAfter(r-1);const o=this.getFocus()[0];if(o!==s&&(void 0===o||o>=s)){const i=this.findNextIndex(s,!1,t);i>-1&&o!==i?this.setFocus([i],e):this.setFocus([s],e)}else{const s=r;this.view.setScrollTop(r-this.view.renderHeight-n),this.view.getScrollTop()+i()!==s&&(this.setFocus([]),await(0,h.wR)(0),await this.focusPreviousPage(e,t,i))}}focusLast(e,t){if(0===this.length)return;const i=this.findPreviousIndex(this.length-1,!1,t);i>-1&&this.setFocus([i],e)}focusFirst(e,t){this.focusNth(0,e,t)}focusNth(e,t,i){if(0===this.length)return;const s=this.findNextIndex(e,!1,i);s>-1&&this.setFocus([s],t)}findNextIndex(e,t=!1,i){for(let s=0;s=this.length&&!t)return-1;if(e%=this.length,!i||i(this.element(e)))return e;e++}return-1}findPreviousIndex(e,t=!1,i){for(let s=0;sthis.view.element(e)))}reveal(e,t,i=0){if(e<0||e>=this.length)throw new C(this.user,`Invalid index ${e}`);const s=this.view.getScrollTop(),n=this.view.elementTop(e),r=this.view.elementHeight(e);if((0,v.Et)(t)){const e=r-this.view.renderHeight+i;this.view.setScrollTop(e*(0,f.qE)(t,0,1)+n-i)}else{const e=n+r,t=s+this.view.renderHeight;n=t||(n=t&&r>=this.view.renderHeight?this.view.setScrollTop(n-i):e>=t&&this.view.setScrollTop(e-this.view.renderHeight))}}getRelativeTop(e,t=0){if(e<0||e>=this.length)throw new C(this.user,`Invalid index ${e}`);const i=this.view.getScrollTop(),s=this.view.elementTop(e),n=this.view.elementHeight(e);if(si+this.view.renderHeight)return null;const r=n-this.view.renderHeight+t;return Math.abs((i+t-s)/r)}getHTMLElement(){return this.view.domNode}getScrollableElement(){return this.view.scrollableElementDomNode}getElementID(e){return this.view.getElementDomId(e)}getElementTop(e){return this.view.elementTop(e)}style(e){this.styleController.style(e)}toListEvent({indexes:e,browserEvent:t}){return{indexes:e,elements:e.map((e=>this.view.element(e))),browserEvent:t}}_onFocusChange(){const e=this.focus.get();this.view.domNode.classList.toggle("element-focused",e.length>0),this.onDidChangeActiveDescendant()}onDidChangeActiveDescendant(){const e=this.focus.get();if(e.length>0){let t;this.accessibilityProvider?.getActiveDescendantId&&(t=this.accessibilityProvider.getActiveDescendantId(this.view.element(e[0]))),this.view.domNode.setAttribute("aria-activedescendant",t||this.view.getElementDomId(e[0]))}else this.view.domNode.removeAttribute("aria-activedescendant")}_onSelectionChange(){const e=this.selection.get();this.view.domNode.classList.toggle("selection-none",0===e.length),this.view.domNode.classList.toggle("selection-single",1===e.length),this.view.domNode.classList.toggle("selection-multiple",e.length>1)}dispose(){this._onDidDispose.fire(),this.disposables.dispose(),this._onDidDispose.dispose()}}L([u.B],ee.prototype,"onDidChangeFocus",null),L([u.B],ee.prototype,"onDidChangeSelection",null),L([u.B],ee.prototype,"onContextMenu",null),L([u.B],ee.prototype,"onKeyDown",null),L([u.B],ee.prototype,"onDidFocus",null),L([u.B],ee.prototype,"onDidBlur",null)},88807:(e,t,i)=>{"use strict";i.d(t,{v:()=>a});var s=i(8597),n=i(92403),r=i(41234),o=i(5662);class a{constructor(){let e;this._onDidWillResize=new r.vl,this.onDidWillResize=this._onDidWillResize.event,this._onDidResize=new r.vl,this.onDidResize=this._onDidResize.event,this._sashListener=new o.Cm,this._size=new s.fg(0,0),this._minSize=new s.fg(0,0),this._maxSize=new s.fg(Number.MAX_SAFE_INTEGER,Number.MAX_SAFE_INTEGER),this.domNode=document.createElement("div"),this._eastSash=new n.m(this.domNode,{getVerticalSashLeft:()=>this._size.width},{orientation:0}),this._westSash=new n.m(this.domNode,{getVerticalSashLeft:()=>0},{orientation:0}),this._northSash=new n.m(this.domNode,{getHorizontalSashTop:()=>0},{orientation:1,orthogonalEdge:n.B.North}),this._southSash=new n.m(this.domNode,{getHorizontalSashTop:()=>this._size.height},{orientation:1,orthogonalEdge:n.B.South}),this._northSash.orthogonalStartSash=this._westSash,this._northSash.orthogonalEndSash=this._eastSash,this._southSash.orthogonalStartSash=this._westSash,this._southSash.orthogonalEndSash=this._eastSash;let t=0,i=0;this._sashListener.add(r.Jh.any(this._northSash.onDidStart,this._eastSash.onDidStart,this._southSash.onDidStart,this._westSash.onDidStart)((()=>{void 0===e&&(this._onDidWillResize.fire(),e=this._size,t=0,i=0)}))),this._sashListener.add(r.Jh.any(this._northSash.onDidEnd,this._eastSash.onDidEnd,this._southSash.onDidEnd,this._westSash.onDidEnd)((()=>{void 0!==e&&(e=void 0,t=0,i=0,this._onDidResize.fire({dimension:this._size,done:!0}))}))),this._sashListener.add(this._eastSash.onDidChange((s=>{e&&(i=s.currentX-s.startX,this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,east:!0}))}))),this._sashListener.add(this._westSash.onDidChange((s=>{e&&(i=-(s.currentX-s.startX),this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,west:!0}))}))),this._sashListener.add(this._northSash.onDidChange((s=>{e&&(t=-(s.currentY-s.startY),this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,north:!0}))}))),this._sashListener.add(this._southSash.onDidChange((s=>{e&&(t=s.currentY-s.startY,this.layout(e.height+t,e.width+i),this._onDidResize.fire({dimension:this._size,done:!1,south:!0}))}))),this._sashListener.add(r.Jh.any(this._eastSash.onDidReset,this._westSash.onDidReset)((e=>{this._preferredSize&&(this.layout(this._size.height,this._preferredSize.width),this._onDidResize.fire({dimension:this._size,done:!0}))}))),this._sashListener.add(r.Jh.any(this._northSash.onDidReset,this._southSash.onDidReset)((e=>{this._preferredSize&&(this.layout(this._preferredSize.height,this._size.width),this._onDidResize.fire({dimension:this._size,done:!0}))})))}dispose(){this._northSash.dispose(),this._southSash.dispose(),this._eastSash.dispose(),this._westSash.dispose(),this._sashListener.dispose(),this._onDidResize.dispose(),this._onDidWillResize.dispose(),this.domNode.remove()}enableSashes(e,t,i,s){this._northSash.state=e?3:0,this._eastSash.state=t?3:0,this._southSash.state=i?3:0,this._westSash.state=s?3:0}layout(e=this.size.height,t=this.size.width){const{height:i,width:n}=this._minSize,{height:r,width:o}=this._maxSize;e=Math.max(i,Math.min(r,e)),t=Math.max(n,Math.min(o,t));const a=new s.fg(t,e);s.fg.equals(a,this._size)||(this.domNode.style.height=e+"px",this.domNode.style.width=t+"px",this._size=a,this._northSash.layout(),this._eastSash.layout(),this._southSash.layout(),this._westSash.layout())}clearSashHoverState(){this._eastSash.clearSashHoverState(),this._westSash.clearSashHoverState(),this._northSash.clearSashHoverState(),this._southSash.clearSashHoverState()}get size(){return this._size}set maxSize(e){this._maxSize=e}get maxSize(){return this._maxSize}set minSize(e){this._minSize=e}get minSize(){return this._minSize}set preferredSize(e){this._preferredSize=e}get preferredSize(){return this._preferredSize}}},92403:(e,t,i)=>{"use strict";i.d(t,{B:()=>u,m:()=>C});var s=i(8597),n=i(56245),r=i(25154),o=i(90766),a=i(58694),l=i(41234),c=i(5662),h=i(98067),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};var u;!function(e){e.North="north",e.South="south",e.East="east",e.West="west"}(u||(u={}));const g=new l.vl;const p=new l.vl;class m{constructor(e){this.el=e,this.disposables=new c.Cm}get onPointerMove(){return this.disposables.add(new n.f((0,s.zk)(this.el),"mousemove")).event}get onPointerUp(){return this.disposables.add(new n.f((0,s.zk)(this.el),"mouseup")).event}dispose(){this.disposables.dispose()}}d([a.B],m.prototype,"onPointerMove",null),d([a.B],m.prototype,"onPointerUp",null);class f{get onPointerMove(){return this.disposables.add(new n.f(this.el,r.B.Change)).event}get onPointerUp(){return this.disposables.add(new n.f(this.el,r.B.End)).event}constructor(e){this.el=e,this.disposables=new c.Cm}dispose(){this.disposables.dispose()}}d([a.B],f.prototype,"onPointerMove",null),d([a.B],f.prototype,"onPointerUp",null);class _{get onPointerMove(){return this.factory.onPointerMove}get onPointerUp(){return this.factory.onPointerUp}constructor(e){this.factory=e}dispose(){}}d([a.B],_.prototype,"onPointerMove",null),d([a.B],_.prototype,"onPointerUp",null);const v="pointer-events-disabled";class C extends c.jG{get state(){return this._state}get orthogonalStartSash(){return this._orthogonalStartSash}get orthogonalEndSash(){return this._orthogonalEndSash}set state(e){this._state!==e&&(this.el.classList.toggle("disabled",0===e),this.el.classList.toggle("minimum",1===e),this.el.classList.toggle("maximum",2===e),this._state=e,this.onDidEnablementChange.fire(e))}set orthogonalStartSash(e){if(this._orthogonalStartSash!==e){if(this.orthogonalStartDragHandleDisposables.clear(),this.orthogonalStartSashDisposables.clear(),e){const t=t=>{this.orthogonalStartDragHandleDisposables.clear(),0!==t&&(this._orthogonalStartDragHandle=(0,s.BC)(this.el,(0,s.$)(".orthogonal-drag-handle.start")),this.orthogonalStartDragHandleDisposables.add((0,c.s)((()=>this._orthogonalStartDragHandle.remove()))),this.orthogonalStartDragHandleDisposables.add(new n.f(this._orthogonalStartDragHandle,"mouseenter")).event((()=>C.onMouseEnter(e)),void 0,this.orthogonalStartDragHandleDisposables),this.orthogonalStartDragHandleDisposables.add(new n.f(this._orthogonalStartDragHandle,"mouseleave")).event((()=>C.onMouseLeave(e)),void 0,this.orthogonalStartDragHandleDisposables))};this.orthogonalStartSashDisposables.add(e.onDidEnablementChange.event(t,this)),t(e.state)}this._orthogonalStartSash=e}}set orthogonalEndSash(e){if(this._orthogonalEndSash!==e){if(this.orthogonalEndDragHandleDisposables.clear(),this.orthogonalEndSashDisposables.clear(),e){const t=t=>{this.orthogonalEndDragHandleDisposables.clear(),0!==t&&(this._orthogonalEndDragHandle=(0,s.BC)(this.el,(0,s.$)(".orthogonal-drag-handle.end")),this.orthogonalEndDragHandleDisposables.add((0,c.s)((()=>this._orthogonalEndDragHandle.remove()))),this.orthogonalEndDragHandleDisposables.add(new n.f(this._orthogonalEndDragHandle,"mouseenter")).event((()=>C.onMouseEnter(e)),void 0,this.orthogonalEndDragHandleDisposables),this.orthogonalEndDragHandleDisposables.add(new n.f(this._orthogonalEndDragHandle,"mouseleave")).event((()=>C.onMouseLeave(e)),void 0,this.orthogonalEndDragHandleDisposables))};this.orthogonalEndSashDisposables.add(e.onDidEnablementChange.event(t,this)),t(e.state)}this._orthogonalEndSash=e}}constructor(e,t,i){super(),this.hoverDelay=300,this.hoverDelayer=this._register(new o.ve(this.hoverDelay)),this._state=3,this.onDidEnablementChange=this._register(new l.vl),this._onDidStart=this._register(new l.vl),this._onDidChange=this._register(new l.vl),this._onDidReset=this._register(new l.vl),this._onDidEnd=this._register(new l.vl),this.orthogonalStartSashDisposables=this._register(new c.Cm),this.orthogonalStartDragHandleDisposables=this._register(new c.Cm),this.orthogonalEndSashDisposables=this._register(new c.Cm),this.orthogonalEndDragHandleDisposables=this._register(new c.Cm),this.onDidStart=this._onDidStart.event,this.onDidChange=this._onDidChange.event,this.onDidReset=this._onDidReset.event,this.onDidEnd=this._onDidEnd.event,this.linkedSash=void 0,this.el=(0,s.BC)(e,(0,s.$)(".monaco-sash")),i.orthogonalEdge&&this.el.classList.add(`orthogonal-edge-${i.orthogonalEdge}`),h.zx&&this.el.classList.add("mac");const a=this._register(new n.f(this.el,"mousedown")).event;this._register(a((t=>this.onPointerStart(t,new m(e))),this));const d=this._register(new n.f(this.el,"dblclick")).event;this._register(d(this.onPointerDoublePress,this));const u=this._register(new n.f(this.el,"mouseenter")).event;this._register(u((()=>C.onMouseEnter(this))));const _=this._register(new n.f(this.el,"mouseleave")).event;this._register(_((()=>C.onMouseLeave(this)))),this._register(r.q.addTarget(this.el));const v=this._register(new n.f(this.el,r.B.Start)).event;this._register(v((e=>this.onPointerStart(e,new f(this.el))),this));const b=this._register(new n.f(this.el,r.B.Tap)).event;let E;this._register(b((e=>{if(E)return clearTimeout(E),E=void 0,void this.onPointerDoublePress(e);clearTimeout(E),E=setTimeout((()=>E=void 0),250)}),this)),"number"===typeof i.size?(this.size=i.size,0===i.orientation?this.el.style.width=`${this.size}px`:this.el.style.height=`${this.size}px`):(this.size=4,this._register(g.event((e=>{this.size=e,this.layout()})))),this._register(p.event((e=>this.hoverDelay=e))),this.layoutProvider=t,this.orthogonalStartSash=i.orthogonalStartSash,this.orthogonalEndSash=i.orthogonalEndSash,this.orientation=i.orientation||0,1===this.orientation?(this.el.classList.add("horizontal"),this.el.classList.remove("vertical")):(this.el.classList.remove("horizontal"),this.el.classList.add("vertical")),this.el.classList.toggle("debug",false),this.layout()}onPointerStart(e,t){s.fs.stop(e);let i=!1;if(!e.__orthogonalSashEvent){const s=this.getOrthogonalSash(e);s&&(i=!0,e.__orthogonalSashEvent=!0,s.onPointerStart(e,new _(t)))}if(this.linkedSash&&!e.__linkedSashEvent&&(e.__linkedSashEvent=!0,this.linkedSash.onPointerStart(e,new _(t))),!this.state)return;const n=this.el.ownerDocument.getElementsByTagName("iframe");for(const s of n)s.classList.add(v);const r=e.pageX,o=e.pageY,a=e.altKey,l={startX:r,currentX:r,startY:o,currentY:o,altKey:a};this.el.classList.add("active"),this._onDidStart.fire(l);const d=(0,s.li)(this.el),u=()=>{let e="";e=i?"all-scroll":1===this.orientation?1===this.state?"s-resize":2===this.state?"n-resize":h.zx?"row-resize":"ns-resize":1===this.state?"e-resize":2===this.state?"w-resize":h.zx?"col-resize":"ew-resize",d.textContent=`* { cursor: ${e} !important; }`},g=new c.Cm;u(),i||this.onDidEnablementChange.event(u,null,g);t.onPointerMove((e=>{s.fs.stop(e,!1);const t={startX:r,currentX:e.pageX,startY:o,currentY:e.pageY,altKey:a};this._onDidChange.fire(t)}),null,g),t.onPointerUp((e=>{s.fs.stop(e,!1),d.remove(),this.el.classList.remove("active"),this._onDidEnd.fire(),g.dispose();for(const t of n)t.classList.remove(v)}),null,g),g.add(t)}onPointerDoublePress(e){const t=this.getOrthogonalSash(e);t&&t._onDidReset.fire(),this.linkedSash&&this.linkedSash._onDidReset.fire(),this._onDidReset.fire()}static onMouseEnter(e,t=!1){e.el.classList.contains("active")?(e.hoverDelayer.cancel(),e.el.classList.add("hover")):e.hoverDelayer.trigger((()=>e.el.classList.add("hover")),e.hoverDelay).then(void 0,(()=>{})),!t&&e.linkedSash&&C.onMouseEnter(e.linkedSash,!0)}static onMouseLeave(e,t=!1){e.hoverDelayer.cancel(),e.el.classList.remove("hover"),!t&&e.linkedSash&&C.onMouseLeave(e.linkedSash,!0)}clearSashHoverState(){C.onMouseLeave(this)}layout(){if(0===this.orientation){const e=this.layoutProvider;this.el.style.left=e.getVerticalSashLeft(this)-this.size/2+"px",e.getVerticalSashTop&&(this.el.style.top=e.getVerticalSashTop(this)+"px"),e.getVerticalSashHeight&&(this.el.style.height=e.getVerticalSashHeight(this)+"px")}else{const e=this.layoutProvider;this.el.style.top=e.getHorizontalSashTop(this)-this.size/2+"px",e.getHorizontalSashLeft&&(this.el.style.left=e.getHorizontalSashLeft(this)+"px"),e.getHorizontalSashWidth&&(this.el.style.width=e.getHorizontalSashWidth(this)+"px")}}getOrthogonalSash(e){const t=e.initialTarget??e.target;if(t&&(0,s.sb)(t))return t.classList.contains("orthogonal-drag-handle")?t.classList.contains("start")?this.orthogonalStartSash:this.orthogonalEndSash:void 0}dispose(){super.dispose(),this.el.remove()}}},31295:(e,t,i)=>{"use strict";i.d(t,{MU:()=>x,QC:()=>w,Se:()=>R,oO:()=>T});var s=i(60413),n=i(8597),r=i(55275),o=i(47358),a=i(34072),l=i(17390),c=i(90766),h=i(25689);const d=11;class u extends l.x{constructor(e){super(),this._onActivate=e.onActivate,this.bgDomNode=document.createElement("div"),this.bgDomNode.className="arrow-background",this.bgDomNode.style.position="absolute",this.bgDomNode.style.width=e.bgWidth+"px",this.bgDomNode.style.height=e.bgHeight+"px","undefined"!==typeof e.top&&(this.bgDomNode.style.top="0px"),"undefined"!==typeof e.left&&(this.bgDomNode.style.left="0px"),"undefined"!==typeof e.bottom&&(this.bgDomNode.style.bottom="0px"),"undefined"!==typeof e.right&&(this.bgDomNode.style.right="0px"),this.domNode=document.createElement("div"),this.domNode.className=e.className,this.domNode.classList.add(...h.L.asClassNameArray(e.icon)),this.domNode.style.position="absolute",this.domNode.style.width="11px",this.domNode.style.height="11px","undefined"!==typeof e.top&&(this.domNode.style.top=e.top+"px"),"undefined"!==typeof e.left&&(this.domNode.style.left=e.left+"px"),"undefined"!==typeof e.bottom&&(this.domNode.style.bottom=e.bottom+"px"),"undefined"!==typeof e.right&&(this.domNode.style.right=e.right+"px"),this._pointerMoveMonitor=this._register(new a._),this._register(n.b2(this.bgDomNode,n.Bx.POINTER_DOWN,(e=>this._arrowPointerDown(e)))),this._register(n.b2(this.domNode,n.Bx.POINTER_DOWN,(e=>this._arrowPointerDown(e)))),this._pointerdownRepeatTimer=this._register(new n.Be),this._pointerdownScheduleRepeatTimer=this._register(new c.pc)}_arrowPointerDown(e){if(!e.target||!(e.target instanceof Element))return;this._onActivate(),this._pointerdownRepeatTimer.cancel(),this._pointerdownScheduleRepeatTimer.cancelAndSet((()=>{this._pointerdownRepeatTimer.cancelAndSet((()=>this._onActivate()),1e3/24,n.zk(e))}),200),this._pointerMoveMonitor.startMonitoring(e.target,e.pointerId,e.buttons,(e=>{}),(()=>{this._pointerdownRepeatTimer.cancel(),this._pointerdownScheduleRepeatTimer.cancel()})),e.preventDefault()}}var g=i(5662);class p extends g.jG{constructor(e,t,i){super(),this._visibility=e,this._visibleClassName=t,this._invisibleClassName=i,this._domNode=null,this._isVisible=!1,this._isNeeded=!1,this._rawShouldBeVisible=!1,this._shouldBeVisible=!1,this._revealTimer=this._register(new c.pc)}setVisibility(e){this._visibility!==e&&(this._visibility=e,this._updateShouldBeVisible())}setShouldBeVisible(e){this._rawShouldBeVisible=e,this._updateShouldBeVisible()}_applyVisibilitySetting(){return 2!==this._visibility&&(3===this._visibility||this._rawShouldBeVisible)}_updateShouldBeVisible(){const e=this._applyVisibilitySetting();this._shouldBeVisible!==e&&(this._shouldBeVisible=e,this.ensureVisibility())}setIsNeeded(e){this._isNeeded!==e&&(this._isNeeded=e,this.ensureVisibility())}setDomNode(e){this._domNode=e,this._domNode.setClassName(this._invisibleClassName),this.setShouldBeVisible(!1)}ensureVisibility(){this._isNeeded?this._shouldBeVisible?this._reveal():this._hide(!0):this._hide(!1)}_reveal(){this._isVisible||(this._isVisible=!0,this._revealTimer.setIfNotSet((()=>{this._domNode?.setClassName(this._visibleClassName)}),0))}_hide(e){this._revealTimer.cancel(),this._isVisible&&(this._isVisible=!1,this._domNode?.setClassName(this._invisibleClassName+(e?" fade":"")))}}var m=i(98067);class f extends l.x{constructor(e){super(),this._lazyRender=e.lazyRender,this._host=e.host,this._scrollable=e.scrollable,this._scrollByPage=e.scrollByPage,this._scrollbarState=e.scrollbarState,this._visibilityController=this._register(new p(e.visibility,"visible scrollbar "+e.extraScrollbarClassName,"invisible scrollbar "+e.extraScrollbarClassName)),this._visibilityController.setIsNeeded(this._scrollbarState.isNeeded()),this._pointerMoveMonitor=this._register(new a._),this._shouldRender=!0,this.domNode=(0,r.Z)(document.createElement("div")),this.domNode.setAttribute("role","presentation"),this.domNode.setAttribute("aria-hidden","true"),this._visibilityController.setDomNode(this.domNode),this.domNode.setPosition("absolute"),this._register(n.ko(this.domNode.domNode,n.Bx.POINTER_DOWN,(e=>this._domNodePointerDown(e))))}_createArrow(e){const t=this._register(new u(e));this.domNode.domNode.appendChild(t.bgDomNode),this.domNode.domNode.appendChild(t.domNode)}_createSlider(e,t,i,s){this.slider=(0,r.Z)(document.createElement("div")),this.slider.setClassName("slider"),this.slider.setPosition("absolute"),this.slider.setTop(e),this.slider.setLeft(t),"number"===typeof i&&this.slider.setWidth(i),"number"===typeof s&&this.slider.setHeight(s),this.slider.setLayerHinting(!0),this.slider.setContain("strict"),this.domNode.domNode.appendChild(this.slider.domNode),this._register(n.ko(this.slider.domNode,n.Bx.POINTER_DOWN,(e=>{0===e.button&&(e.preventDefault(),this._sliderPointerDown(e))}))),this.onclick(this.slider.domNode,(e=>{e.leftButton&&e.stopPropagation()}))}_onElementSize(e){return this._scrollbarState.setVisibleSize(e)&&(this._visibilityController.setIsNeeded(this._scrollbarState.isNeeded()),this._shouldRender=!0,this._lazyRender||this.render()),this._shouldRender}_onElementScrollSize(e){return this._scrollbarState.setScrollSize(e)&&(this._visibilityController.setIsNeeded(this._scrollbarState.isNeeded()),this._shouldRender=!0,this._lazyRender||this.render()),this._shouldRender}_onElementScrollPosition(e){return this._scrollbarState.setScrollPosition(e)&&(this._visibilityController.setIsNeeded(this._scrollbarState.isNeeded()),this._shouldRender=!0,this._lazyRender||this.render()),this._shouldRender}beginReveal(){this._visibilityController.setShouldBeVisible(!0)}beginHide(){this._visibilityController.setShouldBeVisible(!1)}render(){this._shouldRender&&(this._shouldRender=!1,this._renderDomNode(this._scrollbarState.getRectangleLargeSize(),this._scrollbarState.getRectangleSmallSize()),this._updateSlider(this._scrollbarState.getSliderSize(),this._scrollbarState.getArrowSize()+this._scrollbarState.getSliderPosition()))}_domNodePointerDown(e){e.target===this.domNode.domNode&&this._onPointerDown(e)}delegatePointerDown(e){const t=this.domNode.domNode.getClientRects()[0].top,i=t+this._scrollbarState.getSliderPosition(),s=t+this._scrollbarState.getSliderPosition()+this._scrollbarState.getSliderSize(),n=this._sliderPointerPosition(e);i<=n&&n<=s?0===e.button&&(e.preventDefault(),this._sliderPointerDown(e)):this._onPointerDown(e)}_onPointerDown(e){let t,i;if(e.target===this.domNode.domNode&&"number"===typeof e.offsetX&&"number"===typeof e.offsetY)t=e.offsetX,i=e.offsetY;else{const s=n.BK(this.domNode.domNode);t=e.pageX-s.left,i=e.pageY-s.top}const s=this._pointerDownRelativePosition(t,i);this._setDesiredScrollPositionNow(this._scrollByPage?this._scrollbarState.getDesiredScrollPositionFromOffsetPaged(s):this._scrollbarState.getDesiredScrollPositionFromOffset(s)),0===e.button&&(e.preventDefault(),this._sliderPointerDown(e))}_sliderPointerDown(e){if(!e.target||!(e.target instanceof Element))return;const t=this._sliderPointerPosition(e),i=this._sliderOrthogonalPointerPosition(e),s=this._scrollbarState.clone();this.slider.toggleClassName("active",!0),this._pointerMoveMonitor.startMonitoring(e.target,e.pointerId,e.buttons,(e=>{const n=this._sliderOrthogonalPointerPosition(e),r=Math.abs(n-i);if(m.uF&&r>140)return void this._setDesiredScrollPositionNow(s.getScrollPosition());const o=this._sliderPointerPosition(e)-t;this._setDesiredScrollPositionNow(s.getDesiredScrollPositionFromDelta(o))}),(()=>{this.slider.toggleClassName("active",!1),this._host.onDragEnd()})),this._host.onDragStart()}_setDesiredScrollPositionNow(e){const t={};this.writeScrollPosition(t,e),this._scrollable.setScrollPositionNow(t)}updateScrollbarSize(e){this._updateScrollbarSize(e),this._scrollbarState.setScrollbarSize(e),this._shouldRender=!0,this._lazyRender||this.render()}isNeeded(){return this._scrollbarState.isNeeded()}}var _=i(74850),v=i(10350);class C extends f{constructor(e,t,i){const s=e.getScrollDimensions(),n=e.getCurrentScrollPosition();if(super({lazyRender:t.lazyRender,host:i,scrollbarState:new _.m(t.horizontalHasArrows?t.arrowSize:0,2===t.horizontal?0:t.horizontalScrollbarSize,2===t.vertical?0:t.verticalScrollbarSize,s.width,s.scrollWidth,n.scrollLeft),visibility:t.horizontal,extraScrollbarClassName:"horizontal",scrollable:e,scrollByPage:t.scrollByPage}),t.horizontalHasArrows){const e=(t.arrowSize-d)/2,i=(t.horizontalScrollbarSize-d)/2;this._createArrow({className:"scra",icon:v.W.scrollbarButtonLeft,top:i,left:e,bottom:void 0,right:void 0,bgWidth:t.arrowSize,bgHeight:t.horizontalScrollbarSize,onActivate:()=>this._host.onMouseWheel(new o.$(null,1,0))}),this._createArrow({className:"scra",icon:v.W.scrollbarButtonRight,top:i,left:void 0,bottom:void 0,right:e,bgWidth:t.arrowSize,bgHeight:t.horizontalScrollbarSize,onActivate:()=>this._host.onMouseWheel(new o.$(null,-1,0))})}this._createSlider(Math.floor((t.horizontalScrollbarSize-t.horizontalSliderSize)/2),0,void 0,t.horizontalSliderSize)}_updateSlider(e,t){this.slider.setWidth(e),this.slider.setLeft(t)}_renderDomNode(e,t){this.domNode.setWidth(e),this.domNode.setHeight(t),this.domNode.setLeft(0),this.domNode.setBottom(0)}onDidScroll(e){return this._shouldRender=this._onElementScrollSize(e.scrollWidth)||this._shouldRender,this._shouldRender=this._onElementScrollPosition(e.scrollLeft)||this._shouldRender,this._shouldRender=this._onElementSize(e.width)||this._shouldRender,this._shouldRender}_pointerDownRelativePosition(e,t){return e}_sliderPointerPosition(e){return e.pageX}_sliderOrthogonalPointerPosition(e){return e.pageY}_updateScrollbarSize(e){this.slider.setHeight(e)}writeScrollPosition(e,t){e.scrollLeft=t}updateOptions(e){this.updateScrollbarSize(2===e.horizontal?0:e.horizontalScrollbarSize),this._scrollbarState.setOppositeScrollbarSize(2===e.vertical?0:e.verticalScrollbarSize),this._visibilityController.setVisibility(e.horizontal),this._scrollByPage=e.scrollByPage}}class b extends f{constructor(e,t,i){const s=e.getScrollDimensions(),n=e.getCurrentScrollPosition();if(super({lazyRender:t.lazyRender,host:i,scrollbarState:new _.m(t.verticalHasArrows?t.arrowSize:0,2===t.vertical?0:t.verticalScrollbarSize,0,s.height,s.scrollHeight,n.scrollTop),visibility:t.vertical,extraScrollbarClassName:"vertical",scrollable:e,scrollByPage:t.scrollByPage}),t.verticalHasArrows){const e=(t.arrowSize-d)/2,i=(t.verticalScrollbarSize-d)/2;this._createArrow({className:"scra",icon:v.W.scrollbarButtonUp,top:e,left:i,bottom:void 0,right:void 0,bgWidth:t.verticalScrollbarSize,bgHeight:t.arrowSize,onActivate:()=>this._host.onMouseWheel(new o.$(null,0,1))}),this._createArrow({className:"scra",icon:v.W.scrollbarButtonDown,top:void 0,left:i,bottom:e,right:void 0,bgWidth:t.verticalScrollbarSize,bgHeight:t.arrowSize,onActivate:()=>this._host.onMouseWheel(new o.$(null,0,-1))})}this._createSlider(0,Math.floor((t.verticalScrollbarSize-t.verticalSliderSize)/2),t.verticalSliderSize,void 0)}_updateSlider(e,t){this.slider.setHeight(e),this.slider.setTop(t)}_renderDomNode(e,t){this.domNode.setWidth(t),this.domNode.setHeight(e),this.domNode.setRight(0),this.domNode.setTop(0)}onDidScroll(e){return this._shouldRender=this._onElementScrollSize(e.scrollHeight)||this._shouldRender,this._shouldRender=this._onElementScrollPosition(e.scrollTop)||this._shouldRender,this._shouldRender=this._onElementSize(e.height)||this._shouldRender,this._shouldRender}_pointerDownRelativePosition(e,t){return t}_sliderPointerPosition(e){return e.pageY}_sliderOrthogonalPointerPosition(e){return e.pageX}_updateScrollbarSize(e){this.slider.setWidth(e)}writeScrollPosition(e,t){e.scrollTop=t}updateOptions(e){this.updateScrollbarSize(2===e.vertical?0:e.verticalScrollbarSize),this._scrollbarState.setOppositeScrollbarSize(0),this._visibilityController.setVisibility(e.vertical),this._scrollByPage=e.scrollByPage}}var E=i(41234),S=i(49353);class y{constructor(e,t,i){this.timestamp=e,this.deltaX=t,this.deltaY=i,this.score=0}}class w{static{this.INSTANCE=new w}constructor(){this._capacity=5,this._memory=[],this._front=-1,this._rear=-1}isPhysicalMouseWheel(){if(-1===this._front&&-1===this._rear)return!1;let e=1,t=0,i=1,s=this._rear;for(;;){const n=s===this._front?e:Math.pow(2,-i);if(e-=n,t+=this._memory[s].score*n,s===this._front)break;s=(this._capacity+s-1)%this._capacity,i++}return t<=.5}acceptStandardWheelEvent(e){if(s.H8){const t=n.zk(e.browserEvent),i=(0,s.pR)(t);this.accept(Date.now(),e.deltaX*i,e.deltaY*i)}else this.accept(Date.now(),e.deltaX,e.deltaY)}accept(e,t,i){let s=null;const n=new y(e,t,i);-1===this._front&&-1===this._rear?(this._memory[0]=n,this._front=0,this._rear=0):(s=this._memory[this._rear],this._rear=(this._rear+1)%this._capacity,this._rear===this._front&&(this._front=(this._front+1)%this._capacity),this._memory[this._rear]=n),n.score=this._computeScore(n,s)}_computeScore(e,t){if(Math.abs(e.deltaX)>0&&Math.abs(e.deltaY)>0)return 1;let i=.5;if(this._isAlmostInt(e.deltaX)&&this._isAlmostInt(e.deltaY)||(i+=.25),t){const s=Math.abs(e.deltaX),n=Math.abs(e.deltaY),r=Math.abs(t.deltaX),o=Math.abs(t.deltaY),a=Math.max(Math.min(s,r),1),l=Math.max(Math.min(n,o),1),c=Math.max(s,r),h=Math.max(n,o);c%a===0&&h%l===0&&(i-=.5)}return Math.min(Math.max(i,0),1)}_isAlmostInt(e){return Math.abs(Math.round(e)-e)<.01}}class L extends l.x{get options(){return this._options}constructor(e,t,i){super(),this._onScroll=this._register(new E.vl),this.onScroll=this._onScroll.event,this._onWillScroll=this._register(new E.vl),e.style.overflow="hidden",this._options=function(e){const t={lazyRender:"undefined"!==typeof e.lazyRender&&e.lazyRender,className:"undefined"!==typeof e.className?e.className:"",useShadows:"undefined"===typeof e.useShadows||e.useShadows,handleMouseWheel:"undefined"===typeof e.handleMouseWheel||e.handleMouseWheel,flipAxes:"undefined"!==typeof e.flipAxes&&e.flipAxes,consumeMouseWheelIfScrollbarIsNeeded:"undefined"!==typeof e.consumeMouseWheelIfScrollbarIsNeeded&&e.consumeMouseWheelIfScrollbarIsNeeded,alwaysConsumeMouseWheel:"undefined"!==typeof e.alwaysConsumeMouseWheel&&e.alwaysConsumeMouseWheel,scrollYToX:"undefined"!==typeof e.scrollYToX&&e.scrollYToX,mouseWheelScrollSensitivity:"undefined"!==typeof e.mouseWheelScrollSensitivity?e.mouseWheelScrollSensitivity:1,fastScrollSensitivity:"undefined"!==typeof e.fastScrollSensitivity?e.fastScrollSensitivity:5,scrollPredominantAxis:"undefined"===typeof e.scrollPredominantAxis||e.scrollPredominantAxis,mouseWheelSmoothScroll:"undefined"===typeof e.mouseWheelSmoothScroll||e.mouseWheelSmoothScroll,arrowSize:"undefined"!==typeof e.arrowSize?e.arrowSize:11,listenOnDomNode:"undefined"!==typeof e.listenOnDomNode?e.listenOnDomNode:null,horizontal:"undefined"!==typeof e.horizontal?e.horizontal:1,horizontalScrollbarSize:"undefined"!==typeof e.horizontalScrollbarSize?e.horizontalScrollbarSize:10,horizontalSliderSize:"undefined"!==typeof e.horizontalSliderSize?e.horizontalSliderSize:0,horizontalHasArrows:"undefined"!==typeof e.horizontalHasArrows&&e.horizontalHasArrows,vertical:"undefined"!==typeof e.vertical?e.vertical:1,verticalScrollbarSize:"undefined"!==typeof e.verticalScrollbarSize?e.verticalScrollbarSize:10,verticalHasArrows:"undefined"!==typeof e.verticalHasArrows&&e.verticalHasArrows,verticalSliderSize:"undefined"!==typeof e.verticalSliderSize?e.verticalSliderSize:0,scrollByPage:"undefined"!==typeof e.scrollByPage&&e.scrollByPage};t.horizontalSliderSize="undefined"!==typeof e.horizontalSliderSize?e.horizontalSliderSize:t.horizontalScrollbarSize,t.verticalSliderSize="undefined"!==typeof e.verticalSliderSize?e.verticalSliderSize:t.verticalScrollbarSize,m.zx&&(t.className+=" mac");return t}(t),this._scrollable=i,this._register(this._scrollable.onScroll((e=>{this._onWillScroll.fire(e),this._onDidScroll(e),this._onScroll.fire(e)})));const s={onMouseWheel:e=>this._onMouseWheel(e),onDragStart:()=>this._onDragStart(),onDragEnd:()=>this._onDragEnd()};this._verticalScrollbar=this._register(new b(this._scrollable,this._options,s)),this._horizontalScrollbar=this._register(new C(this._scrollable,this._options,s)),this._domNode=document.createElement("div"),this._domNode.className="monaco-scrollable-element "+this._options.className,this._domNode.setAttribute("role","presentation"),this._domNode.style.position="relative",this._domNode.style.overflow="hidden",this._domNode.appendChild(e),this._domNode.appendChild(this._horizontalScrollbar.domNode.domNode),this._domNode.appendChild(this._verticalScrollbar.domNode.domNode),this._options.useShadows?(this._leftShadowDomNode=(0,r.Z)(document.createElement("div")),this._leftShadowDomNode.setClassName("shadow"),this._domNode.appendChild(this._leftShadowDomNode.domNode),this._topShadowDomNode=(0,r.Z)(document.createElement("div")),this._topShadowDomNode.setClassName("shadow"),this._domNode.appendChild(this._topShadowDomNode.domNode),this._topLeftShadowDomNode=(0,r.Z)(document.createElement("div")),this._topLeftShadowDomNode.setClassName("shadow"),this._domNode.appendChild(this._topLeftShadowDomNode.domNode)):(this._leftShadowDomNode=null,this._topShadowDomNode=null,this._topLeftShadowDomNode=null),this._listenOnDomNode=this._options.listenOnDomNode||this._domNode,this._mouseWheelToDispose=[],this._setListeningToMouseWheel(this._options.handleMouseWheel),this.onmouseover(this._listenOnDomNode,(e=>this._onMouseOver(e))),this.onmouseleave(this._listenOnDomNode,(e=>this._onMouseLeave(e))),this._hideTimeout=this._register(new c.pc),this._isDragging=!1,this._mouseIsOver=!1,this._shouldRender=!0,this._revealOnScroll=!0}dispose(){this._mouseWheelToDispose=(0,g.AS)(this._mouseWheelToDispose),super.dispose()}getDomNode(){return this._domNode}getOverviewRulerLayoutInfo(){return{parent:this._domNode,insertBefore:this._verticalScrollbar.domNode.domNode}}delegateVerticalScrollbarPointerDown(e){this._verticalScrollbar.delegatePointerDown(e)}getScrollDimensions(){return this._scrollable.getScrollDimensions()}setScrollDimensions(e){this._scrollable.setScrollDimensions(e,!1)}updateClassName(e){this._options.className=e,m.zx&&(this._options.className+=" mac"),this._domNode.className="monaco-scrollable-element "+this._options.className}updateOptions(e){"undefined"!==typeof e.handleMouseWheel&&(this._options.handleMouseWheel=e.handleMouseWheel,this._setListeningToMouseWheel(this._options.handleMouseWheel)),"undefined"!==typeof e.mouseWheelScrollSensitivity&&(this._options.mouseWheelScrollSensitivity=e.mouseWheelScrollSensitivity),"undefined"!==typeof e.fastScrollSensitivity&&(this._options.fastScrollSensitivity=e.fastScrollSensitivity),"undefined"!==typeof e.scrollPredominantAxis&&(this._options.scrollPredominantAxis=e.scrollPredominantAxis),"undefined"!==typeof e.horizontal&&(this._options.horizontal=e.horizontal),"undefined"!==typeof e.vertical&&(this._options.vertical=e.vertical),"undefined"!==typeof e.horizontalScrollbarSize&&(this._options.horizontalScrollbarSize=e.horizontalScrollbarSize),"undefined"!==typeof e.verticalScrollbarSize&&(this._options.verticalScrollbarSize=e.verticalScrollbarSize),"undefined"!==typeof e.scrollByPage&&(this._options.scrollByPage=e.scrollByPage),this._horizontalScrollbar.updateOptions(this._options),this._verticalScrollbar.updateOptions(this._options),this._options.lazyRender||this._render()}delegateScrollFromMouseWheelEvent(e){this._onMouseWheel(new o.$(e))}_setListeningToMouseWheel(e){if(this._mouseWheelToDispose.length>0!==e&&(this._mouseWheelToDispose=(0,g.AS)(this._mouseWheelToDispose),e)){const e=e=>{this._onMouseWheel(new o.$(e))};this._mouseWheelToDispose.push(n.ko(this._listenOnDomNode,n.Bx.MOUSE_WHEEL,e,{passive:!1}))}}_onMouseWheel(e){if(e.browserEvent?.defaultPrevented)return;const t=w.INSTANCE;t.acceptStandardWheelEvent(e);let i=!1;if(e.deltaY||e.deltaX){let s=e.deltaY*this._options.mouseWheelScrollSensitivity,n=e.deltaX*this._options.mouseWheelScrollSensitivity;this._options.scrollPredominantAxis&&(this._options.scrollYToX&&n+s===0?n=s=0:Math.abs(s)>=Math.abs(n)?n=0:s=0),this._options.flipAxes&&([s,n]=[n,s]);const r=!m.zx&&e.browserEvent&&e.browserEvent.shiftKey;!this._options.scrollYToX&&!r||n||(n=s,s=0),e.browserEvent&&e.browserEvent.altKey&&(n*=this._options.fastScrollSensitivity,s*=this._options.fastScrollSensitivity);const o=this._scrollable.getFutureScrollPosition();let a={};if(s){const e=50*s,t=o.scrollTop-(e<0?Math.floor(e):Math.ceil(e));this._verticalScrollbar.writeScrollPosition(a,t)}if(n){const e=50*n,t=o.scrollLeft-(e<0?Math.floor(e):Math.ceil(e));this._horizontalScrollbar.writeScrollPosition(a,t)}if(a=this._scrollable.validateScrollPosition(a),o.scrollLeft!==a.scrollLeft||o.scrollTop!==a.scrollTop){this._options.mouseWheelSmoothScroll&&t.isPhysicalMouseWheel()?this._scrollable.setScrollPositionSmooth(a):this._scrollable.setScrollPositionNow(a),i=!0}}let s=i;!s&&this._options.alwaysConsumeMouseWheel&&(s=!0),!s&&this._options.consumeMouseWheelIfScrollbarIsNeeded&&(this._verticalScrollbar.isNeeded()||this._horizontalScrollbar.isNeeded())&&(s=!0),s&&(e.preventDefault(),e.stopPropagation())}_onDidScroll(e){this._shouldRender=this._horizontalScrollbar.onDidScroll(e)||this._shouldRender,this._shouldRender=this._verticalScrollbar.onDidScroll(e)||this._shouldRender,this._options.useShadows&&(this._shouldRender=!0),this._revealOnScroll&&this._reveal(),this._options.lazyRender||this._render()}renderNow(){if(!this._options.lazyRender)throw new Error("Please use `lazyRender` together with `renderNow`!");this._render()}_render(){if(this._shouldRender&&(this._shouldRender=!1,this._horizontalScrollbar.render(),this._verticalScrollbar.render(),this._options.useShadows)){const e=this._scrollable.getCurrentScrollPosition(),t=e.scrollTop>0,i=e.scrollLeft>0,s=i?" left":"",n=t?" top":"",r=i||t?" top-left-corner":"";this._leftShadowDomNode.setClassName(`shadow${s}`),this._topShadowDomNode.setClassName(`shadow${n}`),this._topLeftShadowDomNode.setClassName(`shadow${r}${n}${s}`)}}_onDragStart(){this._isDragging=!0,this._reveal()}_onDragEnd(){this._isDragging=!1,this._hide()}_onMouseLeave(e){this._mouseIsOver=!1,this._hide()}_onMouseOver(e){this._mouseIsOver=!0,this._reveal()}_reveal(){this._verticalScrollbar.beginReveal(),this._horizontalScrollbar.beginReveal(),this._scheduleHide()}_hide(){this._mouseIsOver||this._isDragging||(this._verticalScrollbar.beginHide(),this._horizontalScrollbar.beginHide())}_scheduleHide(){this._mouseIsOver||this._isDragging||this._hideTimeout.cancelAndSet((()=>this._hide()),500)}}class R extends L{constructor(e,t){(t=t||{}).mouseWheelSmoothScroll=!1;const i=new S.yE({forceIntegerValues:!0,smoothScrollDuration:0,scheduleAtNextAnimationFrame:t=>n.PG(n.zk(e),t)});super(e,t,i),this._register(i)}setScrollPosition(e){this._scrollable.setScrollPositionNow(e)}}class T extends L{constructor(e,t,i){super(e,t,i)}setScrollPosition(e){e.reuseAnimation?this._scrollable.setScrollPositionSmooth(e,e.reuseAnimation):this._scrollable.setScrollPositionNow(e)}getScrollPosition(){return this._scrollable.getCurrentScrollPosition()}}class x extends L{constructor(e,t){(t=t||{}).mouseWheelSmoothScroll=!1;const i=new S.yE({forceIntegerValues:!1,smoothScrollDuration:0,scheduleAtNextAnimationFrame:t=>n.PG(n.zk(e),t)});super(e,t,i),this._register(i),this._element=e,this._register(this.onScroll((e=>{e.scrollTopChanged&&(this._element.scrollTop=e.scrollTop),e.scrollLeftChanged&&(this._element.scrollLeft=e.scrollLeft)}))),this.scanDomNode()}setScrollPosition(e){this._scrollable.setScrollPositionNow(e)}getScrollPosition(){return this._scrollable.getCurrentScrollPosition()}scanDomNode(){this.setScrollDimensions({width:this._element.clientWidth,scrollWidth:this._element.scrollWidth,height:this._element.clientHeight,scrollHeight:this._element.scrollHeight}),this.setScrollPosition({scrollLeft:this._element.scrollLeft,scrollTop:this._element.scrollTop})}}},74850:(e,t,i)=>{"use strict";i.d(t,{m:()=>s});class s{constructor(e,t,i,s,n,r){this._scrollbarSize=Math.round(t),this._oppositeScrollbarSize=Math.round(i),this._arrowSize=Math.round(e),this._visibleSize=s,this._scrollSize=n,this._scrollPosition=r,this._computedAvailableSize=0,this._computedIsNeeded=!1,this._computedSliderSize=0,this._computedSliderRatio=0,this._computedSliderPosition=0,this._refreshComputedValues()}clone(){return new s(this._arrowSize,this._scrollbarSize,this._oppositeScrollbarSize,this._visibleSize,this._scrollSize,this._scrollPosition)}setVisibleSize(e){const t=Math.round(e);return this._visibleSize!==t&&(this._visibleSize=t,this._refreshComputedValues(),!0)}setScrollSize(e){const t=Math.round(e);return this._scrollSize!==t&&(this._scrollSize=t,this._refreshComputedValues(),!0)}setScrollPosition(e){const t=Math.round(e);return this._scrollPosition!==t&&(this._scrollPosition=t,this._refreshComputedValues(),!0)}setScrollbarSize(e){this._scrollbarSize=Math.round(e)}setOppositeScrollbarSize(e){this._oppositeScrollbarSize=Math.round(e)}static _computeValues(e,t,i,s,n){const r=Math.max(0,i-e),o=Math.max(0,r-2*t),a=s>0&&s>i;if(!a)return{computedAvailableSize:Math.round(r),computedIsNeeded:a,computedSliderSize:Math.round(o),computedSliderRatio:0,computedSliderPosition:0};const l=Math.round(Math.max(20,Math.floor(i*o/s))),c=(o-l)/(s-i),h=n*c;return{computedAvailableSize:Math.round(r),computedIsNeeded:a,computedSliderSize:Math.round(l),computedSliderRatio:c,computedSliderPosition:Math.round(h)}}_refreshComputedValues(){const e=s._computeValues(this._oppositeScrollbarSize,this._arrowSize,this._visibleSize,this._scrollSize,this._scrollPosition);this._computedAvailableSize=e.computedAvailableSize,this._computedIsNeeded=e.computedIsNeeded,this._computedSliderSize=e.computedSliderSize,this._computedSliderRatio=e.computedSliderRatio,this._computedSliderPosition=e.computedSliderPosition}getArrowSize(){return this._arrowSize}getScrollPosition(){return this._scrollPosition}getRectangleLargeSize(){return this._computedAvailableSize}getRectangleSmallSize(){return this._scrollbarSize}isNeeded(){return this._computedIsNeeded}getSliderSize(){return this._computedSliderSize}getSliderPosition(){return this._computedSliderPosition}getDesiredScrollPositionFromOffset(e){if(!this._computedIsNeeded)return 0;const t=e-this._arrowSize-this._computedSliderSize/2;return Math.round(t/this._computedSliderRatio)}getDesiredScrollPositionFromOffsetPaged(e){if(!this._computedIsNeeded)return 0;const t=e-this._arrowSize;let i=this._scrollPosition;return t{"use strict";i.d(t,{X:()=>C,U:()=>b});var s=i(8597),n=i(56245),r=i(92403),o=i(31295),a=i(25890),l=i(47661),c=i(41234),h=i(5662),d=i(1592),u=i(49353),g=i(631);const p={separatorBorder:l.Q1.transparent};class m{set size(e){this._size=e}get size(){return this._size}get visible(){return"undefined"===typeof this._cachedVisibleSize}setVisible(e,t){if(e!==this.visible){e?(this.size=(0,d.qE)(this._cachedVisibleSize,this.viewMinimumSize,this.viewMaximumSize),this._cachedVisibleSize=void 0):(this._cachedVisibleSize="number"===typeof t?t:this.size,this.size=0),this.container.classList.toggle("visible",e);try{this.view.setVisible?.(e)}catch(i){console.error("Splitview: Failed to set visible view"),console.error(i)}}}get minimumSize(){return this.visible?this.view.minimumSize:0}get viewMinimumSize(){return this.view.minimumSize}get maximumSize(){return this.visible?this.view.maximumSize:0}get viewMaximumSize(){return this.view.maximumSize}get priority(){return this.view.priority}get proportionalLayout(){return this.view.proportionalLayout??!0}get snap(){return!!this.view.snap}set enabled(e){this.container.style.pointerEvents=e?"":"none"}constructor(e,t,i,s){this.container=e,this.view=t,this.disposable=s,this._cachedVisibleSize=void 0,"number"===typeof i?(this._size=i,this._cachedVisibleSize=void 0,e.classList.add("visible")):(this._size=0,this._cachedVisibleSize=i.cachedVisibleSize)}layout(e,t){this.layoutContainer(e);try{this.view.layout(this.size,e,t)}catch(i){console.error("Splitview: Failed to layout view"),console.error(i)}}dispose(){this.disposable.dispose()}}class f extends m{layoutContainer(e){this.container.style.top=`${e}px`,this.container.style.height=`${this.size}px`}}class _ extends m{layoutContainer(e){this.container.style.left=`${e}px`,this.container.style.width=`${this.size}px`}}var v,C;!function(e){e[e.Idle=0]="Idle",e[e.Busy=1]="Busy"}(v||(v={})),function(e){e.Distribute={type:"distribute"},e.Split=function(e){return{type:"split",index:e}},e.Auto=function(e){return{type:"auto",index:e}},e.Invisible=function(e){return{type:"invisible",cachedVisibleSize:e}}}(C||(C={}));class b extends h.jG{get orthogonalStartSash(){return this._orthogonalStartSash}get orthogonalEndSash(){return this._orthogonalEndSash}get startSnappingEnabled(){return this._startSnappingEnabled}get endSnappingEnabled(){return this._endSnappingEnabled}set orthogonalStartSash(e){for(const t of this.sashItems)t.sash.orthogonalStartSash=e;this._orthogonalStartSash=e}set orthogonalEndSash(e){for(const t of this.sashItems)t.sash.orthogonalEndSash=e;this._orthogonalEndSash=e}set startSnappingEnabled(e){this._startSnappingEnabled!==e&&(this._startSnappingEnabled=e,this.updateSashEnablement())}set endSnappingEnabled(e){this._endSnappingEnabled!==e&&(this._endSnappingEnabled=e,this.updateSashEnablement())}constructor(e,t={}){super(),this.size=0,this._contentSize=0,this.proportions=void 0,this.viewItems=[],this.sashItems=[],this.state=v.Idle,this._onDidSashChange=this._register(new c.vl),this._onDidSashReset=this._register(new c.vl),this._startSnappingEnabled=!0,this._endSnappingEnabled=!0,this.onDidSashChange=this._onDidSashChange.event,this.onDidSashReset=this._onDidSashReset.event,this.orientation=t.orientation??0,this.inverseAltBehavior=t.inverseAltBehavior??!1,this.proportionalLayout=t.proportionalLayout??!0,this.getSashOrthogonalSize=t.getSashOrthogonalSize,this.el=document.createElement("div"),this.el.classList.add("monaco-split-view2"),this.el.classList.add(0===this.orientation?"vertical":"horizontal"),e.appendChild(this.el),this.sashContainer=(0,s.BC)(this.el,(0,s.$)(".sash-container")),this.viewContainer=(0,s.$)(".split-view-container"),this.scrollable=this._register(new u.yE({forceIntegerValues:!0,smoothScrollDuration:125,scheduleAtNextAnimationFrame:e=>(0,s.PG)((0,s.zk)(this.el),e)})),this.scrollableElement=this._register(new o.oO(this.viewContainer,{vertical:0===this.orientation?t.scrollbarVisibility??1:2,horizontal:1===this.orientation?t.scrollbarVisibility??1:2},this.scrollable));const i=this._register(new n.f(this.viewContainer,"scroll")).event;this._register(i((e=>{const t=this.scrollableElement.getScrollPosition(),i=Math.abs(this.viewContainer.scrollLeft-t.scrollLeft)<=1?void 0:this.viewContainer.scrollLeft,s=Math.abs(this.viewContainer.scrollTop-t.scrollTop)<=1?void 0:this.viewContainer.scrollTop;void 0===i&&void 0===s||this.scrollableElement.setScrollPosition({scrollLeft:i,scrollTop:s})}))),this.onDidScroll=this.scrollableElement.onScroll,this._register(this.onDidScroll((e=>{e.scrollTopChanged&&(this.viewContainer.scrollTop=e.scrollTop),e.scrollLeftChanged&&(this.viewContainer.scrollLeft=e.scrollLeft)}))),(0,s.BC)(this.el,this.scrollableElement.getDomNode()),this.style(t.styles||p),t.descriptor&&(this.size=t.descriptor.size,t.descriptor.views.forEach(((e,t)=>{const i=g.b0(e.visible)||e.visible?e.size:{type:"invisible",cachedVisibleSize:e.size},s=e.view;this.doAddView(s,i,t,!0)})),this._contentSize=this.viewItems.reduce(((e,t)=>e+t.size),0),this.saveProportions())}style(e){e.separatorBorder.isTransparent()?(this.el.classList.remove("separator-border"),this.el.style.removeProperty("--separator-border")):(this.el.classList.add("separator-border"),this.el.style.setProperty("--separator-border",e.separatorBorder.toString()))}addView(e,t,i=this.viewItems.length,s){this.doAddView(e,t,i,s)}layout(e,t){const i=Math.max(this.size,this._contentSize);if(this.size=e,this.layoutContext=t,this.proportions){let t=0;for(let i=0;i0&&(s.size=(0,d.qE)(Math.round(n*e/t),s.minimumSize,s.maximumSize))}}else{const t=(0,a.y1)(this.viewItems.length),s=t.filter((e=>1===this.viewItems[e].priority)),n=t.filter((e=>2===this.viewItems[e].priority));this.resize(this.viewItems.length-1,e-i,void 0,s,n)}this.distributeEmptySpace(),this.layoutViews()}saveProportions(){this.proportionalLayout&&this._contentSize>0&&(this.proportions=this.viewItems.map((e=>e.proportionalLayout&&e.visible?e.size/this._contentSize:void 0)))}onSashStart({sash:e,start:t,alt:i}){for(const s of this.viewItems)s.enabled=!1;const n=this.sashItems.findIndex((t=>t.sash===e)),r=(0,h.qE)((0,s.ko)(this.el.ownerDocument.body,"keydown",(e=>o(this.sashDragState.current,e.altKey))),(0,s.ko)(this.el.ownerDocument.body,"keyup",(()=>o(this.sashDragState.current,!1)))),o=(e,t)=>{const i=this.viewItems.map((e=>e.size));let s,o,l=Number.NEGATIVE_INFINITY,c=Number.POSITIVE_INFINITY;if(this.inverseAltBehavior&&(t=!t),t){if(n===this.sashItems.length-1){const e=this.viewItems[n];l=(e.minimumSize-e.size)/2,c=(e.maximumSize-e.size)/2}else{const e=this.viewItems[n+1];l=(e.size-e.maximumSize)/2,c=(e.size-e.minimumSize)/2}}if(!t){const e=(0,a.y1)(n,-1),t=(0,a.y1)(n+1,this.viewItems.length),r=e.reduce(((e,t)=>e+(this.viewItems[t].minimumSize-i[t])),0),l=e.reduce(((e,t)=>e+(this.viewItems[t].viewMaximumSize-i[t])),0),c=0===t.length?Number.POSITIVE_INFINITY:t.reduce(((e,t)=>e+(i[t]-this.viewItems[t].minimumSize)),0),h=0===t.length?Number.NEGATIVE_INFINITY:t.reduce(((e,t)=>e+(i[t]-this.viewItems[t].viewMaximumSize)),0),d=Math.max(r,h),u=Math.min(c,l),g=this.findFirstSnapIndex(e),p=this.findFirstSnapIndex(t);if("number"===typeof g){const e=this.viewItems[g],t=Math.floor(e.viewMinimumSize/2);s={index:g,limitDelta:e.visible?d-t:d+t,size:e.size}}if("number"===typeof p){const e=this.viewItems[p],t=Math.floor(e.viewMinimumSize/2);o={index:p,limitDelta:e.visible?u+t:u-t,size:e.size}}}this.sashDragState={start:e,current:e,index:n,sizes:i,minDelta:l,maxDelta:c,alt:t,snapBefore:s,snapAfter:o,disposable:r}};o(t,i)}onSashChange({current:e}){const{index:t,start:i,sizes:s,alt:n,minDelta:r,maxDelta:o,snapBefore:a,snapAfter:l}=this.sashDragState;this.sashDragState.current=e;const c=e-i,h=this.resize(t,c,s,void 0,void 0,r,o,a,l);if(n){const e=t===this.sashItems.length-1,i=this.viewItems.map((e=>e.size)),s=e?t:t+1,n=this.viewItems[s],r=n.size-n.maximumSize,o=n.size-n.minimumSize,a=e?t-1:t+1;this.resize(a,-h,i,void 0,void 0,r,o)}this.distributeEmptySpace(),this.layoutViews()}onSashEnd(e){this._onDidSashChange.fire(e),this.sashDragState.disposable.dispose(),this.saveProportions();for(const t of this.viewItems)t.enabled=!0}onViewChange(e,t){const i=this.viewItems.indexOf(e);i<0||i>=this.viewItems.length||(t="number"===typeof t?t:e.size,t=(0,d.qE)(t,e.minimumSize,e.maximumSize),this.inverseAltBehavior&&i>0?(this.resize(i-1,Math.floor((e.size-t)/2)),this.distributeEmptySpace(),this.layoutViews()):(e.size=t,this.relayout([i],void 0)))}resizeView(e,t){if(!(e<0||e>=this.viewItems.length)){if(this.state!==v.Idle)throw new Error("Cant modify splitview");this.state=v.Busy;try{const i=(0,a.y1)(this.viewItems.length).filter((t=>t!==e)),s=[...i.filter((e=>1===this.viewItems[e].priority)),e],n=i.filter((e=>2===this.viewItems[e].priority)),r=this.viewItems[e];t=Math.round(t),t=(0,d.qE)(t,r.minimumSize,Math.min(r.maximumSize,this.size)),r.size=t,this.relayout(s,n)}finally{this.state=v.Idle}}}distributeViewSizes(){const e=[];let t=0;for(const o of this.viewItems)o.maximumSize-o.minimumSize>0&&(e.push(o),t+=o.size);const i=Math.floor(t/e.length);for(const o of e)o.size=(0,d.qE)(i,o.minimumSize,o.maximumSize);const s=(0,a.y1)(this.viewItems.length),n=s.filter((e=>1===this.viewItems[e].priority)),r=s.filter((e=>2===this.viewItems[e].priority));this.relayout(n,r)}getViewSize(e){return e<0||e>=this.viewItems.length?-1:this.viewItems[e].size}doAddView(e,t,i=this.viewItems.length,n){if(this.state!==v.Idle)throw new Error("Cant modify splitview");this.state=v.Busy;try{const o=(0,s.$)(".split-view-view");i===this.viewItems.length?this.viewContainer.appendChild(o):this.viewContainer.insertBefore(o,this.viewContainer.children.item(i));const l=e.onDidChange((e=>this.onViewChange(p,e))),d=(0,h.s)((()=>o.remove())),u=(0,h.qE)(l,d);let g;"number"===typeof t?g=t:("auto"===t.type&&(t=this.areViewsDistributed()?{type:"distribute"}:{type:"split",index:t.index}),g="split"===t.type?this.getViewSize(t.index)/2:"invisible"===t.type?{cachedVisibleSize:t.cachedVisibleSize}:e.minimumSize);const p=0===this.orientation?new f(o,e,g,u):new _(o,e,g,u);if(this.viewItems.splice(i,0,p),this.viewItems.length>1){const e={orthogonalStartSash:this.orthogonalStartSash,orthogonalEndSash:this.orthogonalEndSash},t=0===this.orientation?new r.m(this.sashContainer,{getHorizontalSashTop:e=>this.getSashPosition(e),getHorizontalSashWidth:this.getSashOrthogonalSize},{...e,orientation:1}):new r.m(this.sashContainer,{getVerticalSashLeft:e=>this.getSashPosition(e),getVerticalSashHeight:this.getSashOrthogonalSize},{...e,orientation:0}),s=0===this.orientation?e=>({sash:t,start:e.startY,current:e.currentY,alt:e.altKey}):e=>({sash:t,start:e.startX,current:e.currentX,alt:e.altKey}),n=c.Jh.map(t.onDidStart,s)(this.onSashStart,this),o=c.Jh.map(t.onDidChange,s)(this.onSashChange,this),l=c.Jh.map(t.onDidEnd,(()=>this.sashItems.findIndex((e=>e.sash===t)))),d=l(this.onSashEnd,this),u=t.onDidReset((()=>{const e=this.sashItems.findIndex((e=>e.sash===t)),i=(0,a.y1)(e,-1),s=(0,a.y1)(e+1,this.viewItems.length),n=this.findFirstSnapIndex(i),r=this.findFirstSnapIndex(s);("number"!==typeof n||this.viewItems[n].visible)&&("number"!==typeof r||this.viewItems[r].visible)&&this._onDidSashReset.fire(e)})),g=(0,h.qE)(n,o,d,u,t),p={sash:t,disposable:g};this.sashItems.splice(i-1,0,p)}let m;o.appendChild(e.element),"number"!==typeof t&&"split"===t.type&&(m=[t.index]),n||this.relayout([i],m),n||"number"===typeof t||"distribute"!==t.type||this.distributeViewSizes()}finally{this.state=v.Idle}}relayout(e,t){const i=this.viewItems.reduce(((e,t)=>e+t.size),0);this.resize(this.viewItems.length-1,this.size-i,void 0,e,t),this.distributeEmptySpace(),this.layoutViews(),this.saveProportions()}resize(e,t,i=this.viewItems.map((e=>e.size)),s,n,r=Number.NEGATIVE_INFINITY,o=Number.POSITIVE_INFINITY,l,c){if(e<0||e>=this.viewItems.length)return 0;const h=(0,a.y1)(e,-1),u=(0,a.y1)(e+1,this.viewItems.length);if(n)for(const d of n)(0,a._A)(h,d),(0,a._A)(u,d);if(s)for(const d of s)(0,a.r7)(h,d),(0,a.r7)(u,d);const g=h.map((e=>this.viewItems[e])),p=h.map((e=>i[e])),m=u.map((e=>this.viewItems[e])),f=u.map((e=>i[e])),_=h.reduce(((e,t)=>e+(this.viewItems[t].minimumSize-i[t])),0),v=h.reduce(((e,t)=>e+(this.viewItems[t].maximumSize-i[t])),0),C=0===u.length?Number.POSITIVE_INFINITY:u.reduce(((e,t)=>e+(i[t]-this.viewItems[t].minimumSize)),0),b=0===u.length?Number.NEGATIVE_INFINITY:u.reduce(((e,t)=>e+(i[t]-this.viewItems[t].maximumSize)),0),E=Math.max(_,b,r),S=Math.min(C,v,o);let y=!1;if(l){const e=this.viewItems[l.index],i=t>=l.limitDelta;y=i!==e.visible,e.setVisible(i,l.size)}if(!y&&c){const e=this.viewItems[c.index],i=te+t.size),0);let i=this.size-t;const s=(0,a.y1)(this.viewItems.length-1,-1),n=s.filter((e=>1===this.viewItems[e].priority)),r=s.filter((e=>2===this.viewItems[e].priority));for(const o of r)(0,a._A)(s,o);for(const o of n)(0,a.r7)(s,o);"number"===typeof e&&(0,a.r7)(s,e);for(let o=0;0!==i&&oe+t.size),0);let e=0;for(const t of this.viewItems)t.layout(e,this.layoutContext),e+=t.size;this.sashItems.forEach((e=>e.sash.layout())),this.updateSashEnablement(),this.updateScrollableElement()}updateScrollableElement(){0===this.orientation?this.scrollableElement.setScrollDimensions({height:this.size,scrollHeight:this._contentSize}):this.scrollableElement.setScrollDimensions({width:this.size,scrollWidth:this._contentSize})}updateSashEnablement(){let e=!1;const t=this.viewItems.map((t=>e=t.size-t.minimumSize>0||e));e=!1;const i=this.viewItems.map((t=>e=t.maximumSize-t.size>0||e)),s=[...this.viewItems].reverse();e=!1;const n=s.map((t=>e=t.size-t.minimumSize>0||e)).reverse();e=!1;const r=s.map((t=>e=t.maximumSize-t.size>0||e)).reverse();let o=0;for(let l=0;l0||this.startSnappingEnabled)?e.state=1:d&&t[l]&&(o0)return;if(!e.visible&&e.snap)return t}}areViewsDistributed(){let e,t;for(const i of this.viewItems)if(e=void 0===e?i.size:Math.min(e,i.size),t=void 0===t?i.size:Math.max(t,i.size),t-e>2)return!1;return!0}dispose(){this.sashDragState?.disposable.dispose(),(0,h.AS)(this.viewItems),this.viewItems=[],this.sashItems.forEach((e=>e.disposable.dispose())),this.sashItems=[],super.dispose()}}},35315:(e,t,i)=>{"use strict";i.d(t,{l:()=>c,F:()=>l});var s=i(17390),n=i(25689),r=i(41234),o=i(42904),a=i(48196);const l={inputActiveOptionBorder:"#007ACC00",inputActiveOptionForeground:"#FFFFFF",inputActiveOptionBackground:"#0E639C50"};class c extends s.x{constructor(e){super(),this._onChange=this._register(new r.vl),this.onChange=this._onChange.event,this._onKeyDown=this._register(new r.vl),this.onKeyDown=this._onKeyDown.event,this._opts=e,this._checked=this._opts.isChecked;const t=["monaco-custom-toggle"];this._opts.icon&&(this._icon=this._opts.icon,t.push(...n.L.asClassNameArray(this._icon))),this._opts.actionClassName&&t.push(...this._opts.actionClassName.split(" ")),this._checked&&t.push("checked"),this.domNode=document.createElement("div"),this._hover=this._register((0,a.i)().setupManagedHover(e.hoverDelegate??(0,o.nZ)("mouse"),this.domNode,this._opts.title)),this.domNode.classList.add(...t),this._opts.notFocusable||(this.domNode.tabIndex=0),this.domNode.setAttribute("role","checkbox"),this.domNode.setAttribute("aria-checked",String(this._checked)),this.domNode.setAttribute("aria-label",this._opts.title),this.applyStyles(),this.onclick(this.domNode,(e=>{this.enabled&&(this.checked=!this._checked,this._onChange.fire(!1),e.preventDefault())})),this._register(this.ignoreGesture(this.domNode)),this.onkeydown(this.domNode,(e=>{if(10===e.keyCode||3===e.keyCode)return this.checked=!this._checked,this._onChange.fire(!0),e.preventDefault(),void e.stopPropagation();this._onKeyDown.fire(e)}))}get enabled(){return"true"!==this.domNode.getAttribute("aria-disabled")}focus(){this.domNode.focus()}get checked(){return this._checked}set checked(e){this._checked=e,this.domNode.setAttribute("aria-checked",String(this._checked)),this.domNode.classList.toggle("checked",this._checked),this.applyStyles()}width(){return 22}applyStyles(){this.domNode&&(this.domNode.style.borderColor=this._checked&&this._opts.inputActiveOptionBorder||"",this.domNode.style.color=this._checked&&this._opts.inputActiveOptionForeground||"inherit",this.domNode.style.backgroundColor=this._checked&&this._opts.inputActiveOptionBackground||"")}enable(){this.domNode.setAttribute("aria-disabled",String(!1))}disable(){this.domNode.setAttribute("aria-disabled",String(!0))}}},19466:(e,t,i)=>{"use strict";i.d(t,{DO:()=>q,w0:()=>x,KP:()=>s,RD:()=>O,vD:()=>I});var s,n=i(8597),r=(i(56245),i(72962)),o=(i(11799),i(88443),i(91581)),a=i(66700),l=i(93090),c=i(35315),h=i(37472),d=i(84565),u=(i(36921),i(25890)),g=i(90766),p=i(10350),m=i(25689),f=i(74320),_=i(41234),v=i(26690),C=i(5662),b=i(1592),E=i(631),S=i(78209),y=(i(42904),i(31308)),w=i(11007);class L extends a.ur{constructor(e){super(e.elements.map((e=>e.element))),this.data=e}}function R(e){return e instanceof a.ur?new L(e):e}class T{constructor(e,t){this.modelProvider=e,this.dnd=t,this.autoExpandDisposable=C.jG.None,this.disposables=new C.Cm}getDragURI(e){return this.dnd.getDragURI(e.element)}getDragLabel(e,t){if(this.dnd.getDragLabel)return this.dnd.getDragLabel(e.map((e=>e.element)),t)}onDragStart(e,t){this.dnd.onDragStart?.(R(e),t)}onDragOver(e,t,i,s,n,r=!0){const o=this.dnd.onDragOver(R(e),t&&t.element,i,s,n),a=this.autoExpandNode!==t;if(a&&(this.autoExpandDisposable.dispose(),this.autoExpandNode=t),"undefined"===typeof t)return o;if(a&&"boolean"!==typeof o&&o.autoExpand&&(this.autoExpandDisposable=(0,g.EQ)((()=>{const e=this.modelProvider(),i=e.getNodeLocation(t);e.isCollapsed(i)&&e.setCollapsed(i,!1),this.autoExpandNode=void 0}),500,this.disposables)),"boolean"===typeof o||!o.accept||"undefined"===typeof o.bubble||o.feedback){if(!r){return{accept:"boolean"===typeof o?o:o.accept,effect:"boolean"===typeof o?void 0:o.effect,feedback:[i]}}return o}if(1===o.bubble){const i=this.modelProvider(),r=i.getNodeLocation(t),o=i.getParentNodeLocation(r),a=i.getNode(o),l=o&&i.getListIndex(o);return this.onDragOver(e,a,l,s,n,!1)}const l=this.modelProvider(),c=l.getNodeLocation(t),h=l.getListIndex(c),d=l.getListRenderCount(c);return{...o,feedback:(0,u.y1)(h,h+d)}}drop(e,t,i,s,n){this.autoExpandDisposable.dispose(),this.autoExpandNode=void 0,this.dnd.drop(R(e),t&&t.element,i,s,n)}onDragEnd(e){this.dnd.onDragEnd?.(e)}dispose(){this.disposables.dispose(),this.dnd.dispose()}}class x{constructor(e){this.delegate=e}getHeight(e){return this.delegate.getHeight(e.element)}getTemplateId(e){return this.delegate.getTemplateId(e.element)}hasDynamicHeight(e){return!!this.delegate.hasDynamicHeight&&this.delegate.hasDynamicHeight(e.element)}setDynamicHeight(e,t){this.delegate.setDynamicHeight?.(e.element,t)}}!function(e){e.None="none",e.OnHover="onHover",e.Always="always"}(s||(s={}));class k{get elements(){return this._elements}constructor(e,t=[]){this._elements=t,this.disposables=new C.Cm,this.onDidChange=_.Jh.forEach(e,(e=>this._elements=e),this.disposables)}dispose(){this.disposables.dispose()}}class A{static{this.DefaultIndent=8}constructor(e,t,i,s,n,r={}){this.renderer=e,this.modelProvider=t,this.activeNodes=s,this.renderedIndentGuides=n,this.renderedElements=new Map,this.renderedNodes=new Map,this.indent=A.DefaultIndent,this.hideTwistiesOfChildlessElements=!1,this.shouldRenderIndentGuides=!1,this.activeIndentNodes=new Set,this.indentGuidesDisposable=C.jG.None,this.disposables=new C.Cm,this.templateId=e.templateId,this.updateOptions(r),_.Jh.map(i,(e=>e.node))(this.onDidChangeNodeTwistieState,this,this.disposables),e.onDidChangeTwistieState?.(this.onDidChangeTwistieState,this,this.disposables)}updateOptions(e={}){if("undefined"!==typeof e.indent){const t=(0,b.qE)(e.indent,0,40);if(t!==this.indent){this.indent=t;for(const[e,t]of this.renderedNodes)this.renderTreeElement(e,t)}}if("undefined"!==typeof e.renderIndentGuides){const t=e.renderIndentGuides!==s.None;if(t!==this.shouldRenderIndentGuides){this.shouldRenderIndentGuides=t;for(const[e,t]of this.renderedNodes)this._renderIndentGuides(e,t);if(this.indentGuidesDisposable.dispose(),t){const e=new C.Cm;this.activeNodes.onDidChange(this._onDidChangeActiveNodes,this,e),this.indentGuidesDisposable=e,this._onDidChangeActiveNodes(this.activeNodes.elements)}}}"undefined"!==typeof e.hideTwistiesOfChildlessElements&&(this.hideTwistiesOfChildlessElements=e.hideTwistiesOfChildlessElements)}renderTemplate(e){const t=(0,n.BC)(e,(0,n.$)(".monaco-tl-row")),i=(0,n.BC)(t,(0,n.$)(".monaco-tl-indent")),s=(0,n.BC)(t,(0,n.$)(".monaco-tl-twistie")),r=(0,n.BC)(t,(0,n.$)(".monaco-tl-contents")),o=this.renderer.renderTemplate(r);return{container:e,indent:i,twistie:s,indentGuidesDisposable:C.jG.None,templateData:o}}renderElement(e,t,i,s){this.renderedNodes.set(e,i),this.renderedElements.set(e.element,e),this.renderTreeElement(e,i),this.renderer.renderElement(e,t,i.templateData,s)}disposeElement(e,t,i,s){i.indentGuidesDisposable.dispose(),this.renderer.disposeElement?.(e,t,i.templateData,s),"number"===typeof s&&(this.renderedNodes.delete(e),this.renderedElements.delete(e.element))}disposeTemplate(e){this.renderer.disposeTemplate(e.templateData)}onDidChangeTwistieState(e){const t=this.renderedElements.get(e);t&&this.onDidChangeNodeTwistieState(t)}onDidChangeNodeTwistieState(e){const t=this.renderedNodes.get(e);t&&(this._onDidChangeActiveNodes(this.activeNodes.elements),this.renderTreeElement(e,t))}renderTreeElement(e,t){const i=A.DefaultIndent+(e.depth-1)*this.indent;t.twistie.style.paddingLeft=`${i}px`,t.indent.style.width=i+this.indent-16+"px",e.collapsible?t.container.setAttribute("aria-expanded",String(!e.collapsed)):t.container.removeAttribute("aria-expanded"),t.twistie.classList.remove(...m.L.asClassNameArray(p.W.treeItemExpanded));let s=!1;this.renderer.renderTwistie&&(s=this.renderer.renderTwistie(e.element,t.twistie)),e.collapsible&&(!this.hideTwistiesOfChildlessElements||e.visibleChildrenCount>0)?(s||t.twistie.classList.add(...m.L.asClassNameArray(p.W.treeItemExpanded)),t.twistie.classList.add("collapsible"),t.twistie.classList.toggle("collapsed",e.collapsed)):t.twistie.classList.remove("collapsible","collapsed"),this._renderIndentGuides(e,t)}_renderIndentGuides(e,t){if((0,n.w_)(t.indent),t.indentGuidesDisposable.dispose(),!this.shouldRenderIndentGuides)return;const i=new C.Cm,s=this.modelProvider();for(;;){const r=s.getNodeLocation(e),o=s.getParentNodeLocation(r);if(!o)break;const a=s.getNode(o),l=(0,n.$)(".indent-guide",{style:`width: ${this.indent}px`});this.activeIndentNodes.has(a)&&l.classList.add("active"),0===t.indent.childElementCount?t.indent.appendChild(l):t.indent.insertBefore(l,t.indent.firstElementChild),this.renderedIndentGuides.add(a,l),i.add((0,C.s)((()=>this.renderedIndentGuides.delete(a,l)))),e=a}t.indentGuidesDisposable=i}_onDidChangeActiveNodes(e){if(!this.shouldRenderIndentGuides)return;const t=new Set,i=this.modelProvider();e.forEach((e=>{const s=i.getNodeLocation(e);try{const n=i.getParentNodeLocation(s);e.collapsible&&e.children.length>0&&!e.collapsed?t.add(e):n&&t.add(i.getNode(n))}catch{}})),this.activeIndentNodes.forEach((e=>{t.has(e)||this.renderedIndentGuides.forEach(e,(e=>e.classList.remove("active")))})),t.forEach((e=>{this.activeIndentNodes.has(e)||this.renderedIndentGuides.forEach(e,(e=>e.classList.add("active")))})),this.activeIndentNodes=t}dispose(){this.renderedNodes.clear(),this.renderedElements.clear(),this.indentGuidesDisposable.dispose(),(0,C.AS)(this.disposables)}}class N{get totalCount(){return this._totalCount}get matchCount(){return this._matchCount}constructor(e,t,i){this.tree=e,this.keyboardNavigationLabelProvider=t,this._filter=i,this._totalCount=0,this._matchCount=0,this._pattern="",this._lowercasePattern="",this.disposables=new C.Cm,e.onWillRefilter(this.reset,this,this.disposables)}filter(e,t){let i=1;if(this._filter){const s=this._filter.filter(e,t);if(i="boolean"===typeof s?s?1:0:(0,h.iZ)(s)?(0,h.Mn)(s.visibility):s,0===i)return!1}if(this._totalCount++,!this._pattern)return this._matchCount++,{data:v.ne.Default,visibility:i};const s=this.keyboardNavigationLabelProvider.getKeyboardNavigationLabel(e),n=Array.isArray(s)?s:[s];for(const r of n){const e=r&&r.toString();if("undefined"===typeof e)return{data:v.ne.Default,visibility:i};let t;if(this.tree.findMatchType===O.Contiguous){const i=e.toLowerCase().indexOf(this._lowercasePattern);if(i>-1){t=[Number.MAX_SAFE_INTEGER,0];for(let e=this._lowercasePattern.length;e>0;e--)t.push(i+e-1)}}else t=(0,v.dt)(this._pattern,this._lowercasePattern,0,e,e.toLowerCase(),0,{firstMatchCanBeWeak:!0,boostFullMatch:!0});if(t)return this._matchCount++,1===n.length?{data:t,visibility:i}:{data:{label:e,score:t},visibility:i}}return this.tree.findMode===I.Filter?"number"===typeof this.tree.options.defaultFindVisibility?this.tree.options.defaultFindVisibility:this.tree.options.defaultFindVisibility?this.tree.options.defaultFindVisibility(e):2:{data:v.ne.Default,visibility:i}}reset(){this._totalCount=0,this._matchCount=0}dispose(){(0,C.AS)(this.disposables)}}c.l;c.l;o.x8,c.F;var I,O;!function(e){e[e.Highlight=0]="Highlight",e[e.Filter=1]="Filter"}(I||(I={})),function(e){e[e.Fuzzy=0]="Fuzzy",e[e.Contiguous=1]="Contiguous"}(O||(O={}));C.jG;class D{get pattern(){return this._pattern}get mode(){return this._mode}set mode(e){e!==this._mode&&(this._mode=e,this.widget&&(this.widget.mode=this._mode),this.tree.refilter(),this.render(),this._onDidChangeMode.fire(e))}get matchType(){return this._matchType}set matchType(e){e!==this._matchType&&(this._matchType=e,this.widget&&(this.widget.matchType=this._matchType),this.tree.refilter(),this.render(),this._onDidChangeMatchType.fire(e))}constructor(e,t,i,s,n,r={}){this.tree=e,this.view=i,this.filter=s,this.contextViewProvider=n,this.options=r,this._pattern="",this.width=0,this._onDidChangeMode=new _.vl,this.onDidChangeMode=this._onDidChangeMode.event,this._onDidChangeMatchType=new _.vl,this.onDidChangeMatchType=this._onDidChangeMatchType.event,this._onDidChangePattern=new _.vl,this._onDidChangeOpenState=new _.vl,this.onDidChangeOpenState=this._onDidChangeOpenState.event,this.enabledDisposables=new C.Cm,this.disposables=new C.Cm,this._mode=e.options.defaultFindMode??I.Highlight,this._matchType=e.options.defaultFindMatchType??O.Fuzzy,t.onDidSplice(this.onDidSpliceModel,this,this.disposables)}updateOptions(e={}){void 0!==e.defaultFindMode&&(this.mode=e.defaultFindMode),void 0!==e.defaultFindMatchType&&(this.matchType=e.defaultFindMatchType)}onDidSpliceModel(){this.widget&&0!==this.pattern.length&&(this.tree.refilter(),this.render())}render(){const e=this.filter.totalCount>0&&0===this.filter.matchCount;this.pattern&&e?((0,w.xE)((0,S.kg)("replFindNoResults","No results")),this.tree.options.showNotFoundMessage??1?this.widget?.showMessage({type:2,content:(0,S.kg)("not found","No elements found.")}):this.widget?.showMessage({type:2})):(this.widget?.clearMessage(),this.pattern&&(0,w.xE)((0,S.kg)("replFindResults","{0} results",this.filter.matchCount)))}shouldAllowFocus(e){return!this.widget||!this.pattern||(this.filter.totalCount>0&&this.filter.matchCount<=1||!v.ne.isDefault(e.filterData))}layout(e){this.width=e,this.widget?.layout(e)}dispose(){this._history=void 0,this._onDidChangePattern.dispose(),this.enabledDisposables.dispose(),this.disposables.dispose()}}function M(e,t){return e.position===t.position&&P(e,t)}function P(e,t){return e.node.element===t.node.element&&e.startIndex===t.startIndex&&e.height===t.height&&e.endIndex===t.endIndex}class F{constructor(e=[]){this.stickyNodes=e}get count(){return this.stickyNodes.length}equal(e){return(0,u.aI)(this.stickyNodes,e.stickyNodes,M)}lastNodePartiallyVisible(){if(0===this.count)return!1;const e=this.stickyNodes[this.count-1];if(1===this.count)return 0!==e.position;const t=this.stickyNodes[this.count-2];return t.position+t.height!==e.position}animationStateChanged(e){if(!(0,u.aI)(this.stickyNodes,e.stickyNodes,P))return!1;if(0===this.count)return!1;const t=this.stickyNodes[this.count-1],i=e.stickyNodes[e.count-1];return t.position!==i.position}}class U{constrainStickyScrollNodes(e,t,i){for(let s=0;si||s>=t)return e.slice(0,s)}return e}}class H extends C.jG{constructor(e,t,i,s,n,r={}){super(),this.tree=e,this.model=t,this.view=i,this.treeDelegate=n,this.maxWidgetViewRatio=.4;const o=this.validateStickySettings(r);this.stickyScrollMaxItemCount=o.stickyScrollMaxItemCount,this.stickyScrollDelegate=r.stickyScrollDelegate??new U,this._widget=this._register(new B(i.getScrollableElement(),i,e,s,n,r.accessibilityProvider)),this.onDidChangeHasFocus=this._widget.onDidChangeHasFocus,this.onContextMenu=this._widget.onContextMenu,this._register(i.onDidScroll((()=>this.update()))),this._register(i.onDidChangeContentHeight((()=>this.update()))),this._register(e.onDidChangeCollapseState((()=>this.update()))),this.update()}get height(){return this._widget.height}getNodeAtHeight(e){let t;if(t=0===e?this.view.firstVisibleIndex:this.view.indexAt(e+this.view.scrollTop),!(t<0||t>=this.view.length))return this.view.element(t)}update(){const e=this.getNodeAtHeight(0);if(!e||0===this.tree.scrollTop)return void this._widget.setState(void 0);const t=this.findStickyState(e);this._widget.setState(t)}findStickyState(e){const t=[];let i=e,s=0,n=this.getNextStickyNode(i,void 0,s);for(;n&&(t.push(n),s+=n.height,!(t.length<=this.stickyScrollMaxItemCount)||(i=this.getNextVisibleNode(n),i));)n=this.getNextStickyNode(i,n.node,s);const r=this.constrainStickyNodes(t);return r.length?new F(r):void 0}getNextVisibleNode(e){return this.getNodeAtHeight(e.position+e.height)}getNextStickyNode(e,t,i){const s=this.getAncestorUnderPrevious(e,t);if(s){if(s===e){if(!this.nodeIsUncollapsedParent(e))return;if(this.nodeTopAlignsWithStickyNodesBottom(e,i))return}return this.createStickyScrollNode(s,i)}}nodeTopAlignsWithStickyNodesBottom(e,t){const i=this.getNodeIndex(e),s=this.view.getElementTop(i),n=t;return this.view.scrollTop===s-n}createStickyScrollNode(e,t){const i=this.treeDelegate.getHeight(e),{startIndex:s,endIndex:n}=this.getNodeRange(e);return{node:e,position:this.calculateStickyNodePosition(n,t,i),height:i,startIndex:s,endIndex:n}}getAncestorUnderPrevious(e,t=void 0){let i=e,s=this.getParentNode(i);for(;s;){if(s===t)return i;i=s,s=this.getParentNode(i)}if(void 0===t)return i}calculateStickyNodePosition(e,t,i){let s=this.view.getRelativeTop(e);if(null===s&&this.view.firstVisibleIndex===e&&e+1o&&t<=o?o-i:t}constrainStickyNodes(e){if(0===e.length)return[];const t=this.view.renderHeight*this.maxWidgetViewRatio,i=e[e.length-1];if(e.length<=this.stickyScrollMaxItemCount&&i.position+i.height<=t)return e;const s=this.stickyScrollDelegate.constrainStickyScrollNodes(e,this.stickyScrollMaxItemCount,t);if(!s.length)return[];const n=s[s.length-1];if(s.length>this.stickyScrollMaxItemCount||n.position+n.height>t)throw new Error("stickyScrollDelegate violates constraints");return s}getParentNode(e){const t=this.model.getNodeLocation(e),i=this.model.getParentNodeLocation(t);return i?this.model.getNode(i):void 0}nodeIsUncollapsedParent(e){const t=this.model.getNodeLocation(e);return this.model.getListRenderCount(t)>1}getNodeIndex(e){const t=this.model.getNodeLocation(e);return this.model.getListIndex(t)}getNodeRange(e){const t=this.model.getNodeLocation(e),i=this.model.getListIndex(t);if(i<0)throw new Error("Node not found in tree");return{startIndex:i,endIndex:i+this.model.getListRenderCount(t)-1}}nodePositionTopBelowWidget(e){const t=[];let i=this.getParentNode(e);for(;i;)t.push(i),i=this.getParentNode(i);let s=0;for(let n=0;n0,i=!!e&&e.count>0;if(!t&&!i||t&&i&&this._previousState.equal(e))return;if(t!==i&&this.setVisible(i),!i)return this._previousState=void 0,this._previousElements=[],void this._previousStateDisposables.clear();const s=e.stickyNodes[e.count-1];if(this._previousState&&e.animationStateChanged(this._previousState))this._previousElements[this._previousState.count-1].style.top=`${s.position}px`;else{this._previousStateDisposables.clear();const t=Array(e.count);for(let i=e.count-1;i>=0;i--){const s=e.stickyNodes[i],{element:n,disposable:r}=this.createElement(s,i,e.count);t[i]=n,this._rootDomNode.appendChild(n),this._previousStateDisposables.add(r)}this.stickyScrollFocus.updateElements(t,e),this._previousElements=t}this._previousState=e,this._rootDomNode.style.height=`${s.position+s.height}px`}createElement(e,t,i){const s=e.startIndex,n=document.createElement("div");n.style.top=`${e.position}px`,!1!==this.tree.options.setRowHeight&&(n.style.height=`${e.height}px`),!1!==this.tree.options.setRowLineHeight&&(n.style.lineHeight=`${e.height}px`),n.classList.add("monaco-tree-sticky-row"),n.classList.add("monaco-list-row"),n.setAttribute("data-index",`${s}`),n.setAttribute("data-parity",s%2===0?"even":"odd"),n.setAttribute("id",this.view.getElementID(s));const r=this.setAccessibilityAttributes(n,e.node.element,t,i),o=this.treeDelegate.getTemplateId(e.node),a=this.treeRenderers.find((e=>e.templateId===o));if(!a)throw new Error(`No renderer found for template id ${o}`);let l=e.node;l===this.tree.getNode(this.tree.getNodeLocation(e.node))&&(l=new Proxy(e.node,{}));const c=a.renderTemplate(n);a.renderElement(l,e.startIndex,c,e.height);const h=(0,C.s)((()=>{r.dispose(),a.disposeElement(l,e.startIndex,c,e.height),a.disposeTemplate(c),n.remove()}));return{element:n,disposable:h}}setAccessibilityAttributes(e,t,i,s){if(!this.accessibilityProvider)return C.jG.None;this.accessibilityProvider.getSetSize&&e.setAttribute("aria-setsize",String(this.accessibilityProvider.getSetSize(t,i,s))),this.accessibilityProvider.getPosInSet&&e.setAttribute("aria-posinset",String(this.accessibilityProvider.getPosInSet(t,i))),this.accessibilityProvider.getRole&&e.setAttribute("role",this.accessibilityProvider.getRole(t)??"treeitem");const n=this.accessibilityProvider.getAriaLabel(t),r=n&&"string"!==typeof n?n:(0,y.lk)(n),o=(0,y.fm)((t=>{const i=t.readObservable(r);i?e.setAttribute("aria-label",i):e.removeAttribute("aria-label")}));"string"===typeof n||n&&e.setAttribute("aria-label",n.get());const a=this.accessibilityProvider.getAriaLevel&&this.accessibilityProvider.getAriaLevel(t);return"number"===typeof a&&e.setAttribute("aria-level",`${a}`),e.setAttribute("aria-selected",String(!1)),o}setVisible(e){this._rootDomNode.classList.toggle("empty",!e),e||this.stickyScrollFocus.updateElements([],void 0)}domFocus(){this.stickyScrollFocus.domFocus()}focusedLast(){return this.stickyScrollFocus.focusedLast()}dispose(){this.stickyScrollFocus.dispose(),this._previousStateDisposables.dispose(),this._rootDomNode.remove()}}class W extends C.jG{get domHasFocus(){return this._domHasFocus}set domHasFocus(e){e!==this._domHasFocus&&(this._onDidChangeHasFocus.fire(e),this._domHasFocus=e)}constructor(e,t){super(),this.container=e,this.view=t,this.focusedIndex=-1,this.elements=[],this._onDidChangeHasFocus=new _.vl,this.onDidChangeHasFocus=this._onDidChangeHasFocus.event,this._onContextMenu=new _.vl,this.onContextMenu=this._onContextMenu.event,this._domHasFocus=!1,this._register((0,n.ko)(this.container,"focus",(()=>this.onFocus()))),this._register((0,n.ko)(this.container,"blur",(()=>this.onBlur()))),this._register(this.view.onDidFocus((()=>this.toggleStickyScrollFocused(!1)))),this._register(this.view.onKeyDown((e=>this.onKeyDown(e)))),this._register(this.view.onMouseDown((e=>this.onMouseDown(e)))),this._register(this.view.onContextMenu((e=>this.handleContextMenu(e))))}handleContextMenu(e){const t=e.browserEvent.target;if(!(0,l.Es)(t)&&!(0,l.xu)(t))return void(this.focusedLast()&&this.view.domFocus());if(!(0,n.kx)(e.browserEvent)){if(!this.state)throw new Error("Context menu should not be triggered when state is undefined");const t=this.state.stickyNodes.findIndex((t=>t.node.element===e.element?.element));if(-1===t)throw new Error("Context menu should not be triggered when element is not in sticky scroll widget");return this.container.focus(),void this.setFocus(t)}if(!this.state||this.focusedIndex<0)throw new Error("Context menu key should not be triggered when focus is not in sticky scroll widget");const i=this.state.stickyNodes[this.focusedIndex].node.element,s=this.elements[this.focusedIndex];this._onContextMenu.fire({element:i,anchor:s,browserEvent:e.browserEvent,isStickyScroll:!0})}onKeyDown(e){if(this.domHasFocus&&this.state)if("ArrowUp"===e.key)this.setFocusedElement(Math.max(0,this.focusedIndex-1)),e.preventDefault(),e.stopPropagation();else if("ArrowDown"===e.key||"ArrowRight"===e.key){if(this.focusedIndex>=this.state.count-1){const e=this.state.stickyNodes[this.state.count-1].startIndex+1;this.view.domFocus(),this.view.setFocus([e]),this.scrollNodeUnderWidget(e,this.state)}else this.setFocusedElement(this.focusedIndex+1);e.preventDefault(),e.stopPropagation()}}onMouseDown(e){const t=e.browserEvent.target;((0,l.Es)(t)||(0,l.xu)(t))&&(e.browserEvent.preventDefault(),e.browserEvent.stopPropagation())}updateElements(e,t){if(t&&0===t.count)throw new Error("Sticky scroll state must be undefined when there are no sticky nodes");if(t&&t.count!==e.length)throw new Error("Sticky scroll focus received illigel state");const i=this.focusedIndex;if(this.removeFocus(),this.elements=e,this.state=t,t){const e=(0,b.qE)(i,0,t.count-1);this.setFocus(e)}else this.domHasFocus&&this.view.domFocus();this.container.tabIndex=t?0:-1}setFocusedElement(e){const t=this.state;if(!t)throw new Error("Cannot set focus when state is undefined");if(this.setFocus(e),!(e1?t.stickyNodes[t.count-2]:void 0,n=this.view.getElementTop(e),r=s?s.position+s.height+i.height:i.height;this.view.scrollTop=n-r}domFocus(){if(!this.state)throw new Error("Cannot focus when state is undefined");this.container.focus()}focusedLast(){return!!this.state&&this.view.getHTMLElement().classList.contains("sticky-scroll-focused")}removeFocus(){-1!==this.focusedIndex&&(this.toggleElementFocus(this.elements[this.focusedIndex],!1),this.focusedIndex=-1)}setFocus(e){if(0>e)throw new Error("addFocus() can not remove focus");if(!this.state&&e>=0)throw new Error("Cannot set focus index when state is undefined");if(this.state&&e>=this.state.count)throw new Error("Cannot set focus index to an index that does not exist");const t=this.focusedIndex;t>=0&&this.toggleElementFocus(this.elements[t],!1),e>=0&&this.toggleElementFocus(this.elements[e],!0),this.focusedIndex=e}toggleElementFocus(e,t){this.toggleElementActiveFocus(e,t&&this.domHasFocus),this.toggleElementPassiveFocus(e,t)}toggleCurrentElementActiveFocus(e){-1!==this.focusedIndex&&this.toggleElementActiveFocus(this.elements[this.focusedIndex],e)}toggleElementActiveFocus(e,t){e.classList.toggle("focused",t)}toggleElementPassiveFocus(e,t){e.classList.toggle("passive-focused",t)}toggleStickyScrollFocused(e){this.view.getHTMLElement().classList.toggle("sticky-scroll-focused",e)}onFocus(){if(!this.state||0===this.elements.length)throw new Error("Cannot focus when state is undefined or elements are empty");this.domHasFocus=!0,this.toggleStickyScrollFocused(!0),this.toggleCurrentElementActiveFocus(!0),-1===this.focusedIndex&&this.setFocus(0)}onBlur(){this.domHasFocus=!1,this.toggleCurrentElementActiveFocus(!1)}dispose(){this.toggleStickyScrollFocused(!1),this._onDidChangeHasFocus.fire(!1),super.dispose()}}function V(e){let t=d.Lx.Unknown;return(0,n.XD)(e.browserEvent.target,"monaco-tl-twistie","monaco-tl-row")?t=d.Lx.Twistie:(0,n.XD)(e.browserEvent.target,"monaco-tl-contents","monaco-tl-row")?t=d.Lx.Element:(0,n.XD)(e.browserEvent.target,"monaco-tree-type-filter","monaco-list")&&(t=d.Lx.Filter),{browserEvent:e.browserEvent,element:e.element?e.element.element:null,target:t}}function z(e){const t=(0,l.Es)(e.browserEvent.target);return{element:e.element?e.element.element:null,browserEvent:e.browserEvent,anchor:e.anchor,isStickyScroll:t}}function G(e,t){t(e),e.children.forEach((e=>G(e,t)))}class j{get nodeSet(){return this._nodeSet||(this._nodeSet=this.createNodeSet()),this._nodeSet}constructor(e,t){this.getFirstViewElementWithTrait=e,this.identityProvider=t,this.nodes=[],this._onDidChange=new _.vl,this.onDidChange=this._onDidChange.event}set(e,t){!t?.__forceEvent&&(0,u.aI)(this.nodes,e)||this._set(e,!1,t)}_set(e,t,i){if(this.nodes=[...e],this.elements=void 0,this._nodeSet=void 0,!t){const e=this;this._onDidChange.fire({get elements(){return e.get()},browserEvent:i})}}get(){return this.elements||(this.elements=this.nodes.map((e=>e.element))),[...this.elements]}getNodes(){return this.nodes}has(e){return this.nodeSet.has(e)}onDidModelSplice({insertedNodes:e,deletedNodes:t}){if(!this.identityProvider){const e=this.createNodeSet(),i=t=>e.delete(t);return t.forEach((e=>G(e,i))),void this.set([...e.values()])}const i=new Set,s=e=>i.add(this.identityProvider.getId(e.element).toString());t.forEach((e=>G(e,s)));const n=new Map,r=e=>n.set(this.identityProvider.getId(e.element).toString(),e);e.forEach((e=>G(e,r)));const o=[];for(const a of this.nodes){const e=this.identityProvider.getId(a.element).toString();if(i.has(e)){const t=n.get(e);t&&t.visible&&o.push(t)}else o.push(a)}if(this.nodes.length>0&&0===o.length){const e=this.getFirstViewElementWithTrait();e&&o.push(e)}this._set(o,!0)}createNodeSet(){const e=new Set;for(const t of this.nodes)e.add(t);return e}}class K extends l.MH{constructor(e,t,i){super(e),this.tree=t,this.stickyScrollProvider=i}onViewPointer(e){if((0,l.Bm)(e.browserEvent.target)||(0,l.B6)(e.browserEvent.target)||(0,l.bm)(e.browserEvent.target))return;if(e.browserEvent.isHandledByList)return;const t=e.element;if(!t)return super.onViewPointer(e);if(this.isSelectionRangeChangeEvent(e)||this.isSelectionSingleChangeEvent(e))return super.onViewPointer(e);const i=e.browserEvent.target,s=i.classList.contains("monaco-tl-twistie")||i.classList.contains("monaco-icon-label")&&i.classList.contains("folder-icon")&&e.browserEvent.offsetX<16,n=(0,l.xu)(e.browserEvent.target);let r=!1;if(r=!!n||("function"===typeof this.tree.expandOnlyOnTwistieClick?this.tree.expandOnlyOnTwistieClick(t.element):!!this.tree.expandOnlyOnTwistieClick),n)this.handleStickyScrollMouseEvent(e,t);else{if(r&&!s&&2!==e.browserEvent.detail)return super.onViewPointer(e);if(!this.tree.expandOnDoubleClick&&2===e.browserEvent.detail)return super.onViewPointer(e)}if(t.collapsible&&(!n||s)){const i=this.tree.getNodeLocation(t),n=e.browserEvent.altKey;if(this.tree.setFocus([i]),this.tree.toggleCollapsed(i,n),s)return void(e.browserEvent.isHandledByList=!0)}n||super.onViewPointer(e)}handleStickyScrollMouseEvent(e,t){if((0,l.b$)(e.browserEvent.target)||(0,l.W0)(e.browserEvent.target))return;const i=this.stickyScrollProvider();if(!i)throw new Error("Sticky scroll controller not found");const s=this.list.indexOf(t),n=this.list.getElementTop(s),r=i.nodePositionTopBelowWidget(t);this.tree.scrollTop=n-r,this.list.domFocus(),this.list.setFocus([s]),this.list.setSelection([s])}onDoubleClick(e){!e.browserEvent.target.classList.contains("monaco-tl-twistie")&&this.tree.expandOnDoubleClick&&(e.browserEvent.isHandledByList||super.onDoubleClick(e))}onMouseDown(e){const t=e.browserEvent.target;(0,l.Es)(t)||(0,l.xu)(t)||super.onMouseDown(e)}onContextMenu(e){const t=e.browserEvent.target;(0,l.Es)(t)||(0,l.xu)(t)||super.onContextMenu(e)}}class Y extends l.B8{constructor(e,t,i,s,n,r,o,a){super(e,t,i,s,a),this.focusTrait=n,this.selectionTrait=r,this.anchorTrait=o}createMouseController(e){return new K(this,e.tree,e.stickyScrollProvider)}splice(e,t,i=[]){if(super.splice(e,t,i),0===i.length)return;const s=[],n=[];let r;i.forEach(((t,i)=>{this.focusTrait.has(t)&&s.push(e+i),this.selectionTrait.has(t)&&n.push(e+i),this.anchorTrait.has(t)&&(r=e+i)})),s.length>0&&super.setFocus((0,u.dM)([...super.getFocus(),...s])),n.length>0&&super.setSelection((0,u.dM)([...super.getSelection(),...n])),"number"===typeof r&&super.setAnchor(r)}setFocus(e,t,i=!1){super.setFocus(e,t),i||this.focusTrait.set(e.map((e=>this.element(e))),t)}setSelection(e,t,i=!1){super.setSelection(e,t),i||this.selectionTrait.set(e.map((e=>this.element(e))),t)}setAnchor(e,t=!1){super.setAnchor(e),t||("undefined"===typeof e?this.anchorTrait.set([]):this.anchorTrait.set([this.element(e)]))}}class q{get onDidScroll(){return this.view.onDidScroll}get onDidChangeFocus(){return this.eventBufferer.wrapEvent(this.focus.onDidChange)}get onDidChangeSelection(){return this.eventBufferer.wrapEvent(this.selection.onDidChange)}get onMouseDblClick(){return _.Jh.filter(_.Jh.map(this.view.onMouseDblClick,V),(e=>e.target!==d.Lx.Filter))}get onMouseOver(){return _.Jh.map(this.view.onMouseOver,V)}get onMouseOut(){return _.Jh.map(this.view.onMouseOut,V)}get onContextMenu(){return _.Jh.any(_.Jh.filter(_.Jh.map(this.view.onContextMenu,z),(e=>!e.isStickyScroll)),this.stickyScrollController?.onContextMenu??_.Jh.None)}get onPointer(){return _.Jh.map(this.view.onPointer,V)}get onKeyDown(){return this.view.onKeyDown}get onDidFocus(){return this.view.onDidFocus}get onDidChangeModel(){return _.Jh.signal(this.model.onDidSplice)}get onDidChangeCollapseState(){return this.model.onDidChangeCollapseState}get findMode(){return this.findController?.mode??I.Highlight}set findMode(e){this.findController&&(this.findController.mode=e)}get findMatchType(){return this.findController?.matchType??O.Fuzzy}set findMatchType(e){this.findController&&(this.findController.matchType=e)}get expandOnDoubleClick(){return"undefined"===typeof this._options.expandOnDoubleClick||this._options.expandOnDoubleClick}get expandOnlyOnTwistieClick(){return"undefined"===typeof this._options.expandOnlyOnTwistieClick||this._options.expandOnlyOnTwistieClick}get onDidDispose(){return this.view.onDidDispose}constructor(e,t,i,o,a={}){this._user=e,this._options=a,this.eventBufferer=new _.at,this.onDidChangeFindOpenState=_.Jh.None,this.onDidChangeStickyScrollFocused=_.Jh.None,this.disposables=new C.Cm,this._onWillRefilter=new _.vl,this.onWillRefilter=this._onWillRefilter.event,this._onDidUpdateOptions=new _.vl,this.treeDelegate=new x(i);const c=new _.Wj,h=new _.Wj,d=this.disposables.add(new k(h.event)),u=new f.db;this.renderers=o.map((e=>new A(e,(()=>this.model),c.event,d,u,a)));for(const s of this.renderers)this.disposables.add(s);let p;var m,v;a.keyboardNavigationLabelProvider&&(p=new N(this,a.keyboardNavigationLabelProvider,a.filter),a={...a,filter:p},this.disposables.add(p)),this.focus=new j((()=>this.view.getFocusedElements()[0]),a.identityProvider),this.selection=new j((()=>this.view.getSelectedElements()[0]),a.identityProvider),this.anchor=new j((()=>this.view.getAnchorElement()),a.identityProvider),this.view=new Y(e,t,this.treeDelegate,this.renderers,this.focus,this.selection,this.anchor,{...(m=()=>this.model,v=a,v&&{...v,identityProvider:v.identityProvider&&{getId:e=>v.identityProvider.getId(e.element)},dnd:v.dnd&&new T(m,v.dnd),multipleSelectionController:v.multipleSelectionController&&{isSelectionSingleChangeEvent:e=>v.multipleSelectionController.isSelectionSingleChangeEvent({...e,element:e.element}),isSelectionRangeChangeEvent:e=>v.multipleSelectionController.isSelectionRangeChangeEvent({...e,element:e.element})},accessibilityProvider:v.accessibilityProvider&&{...v.accessibilityProvider,getSetSize(e){const t=m(),i=t.getNodeLocation(e),s=t.getParentNodeLocation(i);return t.getNode(s).visibleChildrenCount},getPosInSet:e=>e.visibleChildIndex+1,isChecked:v.accessibilityProvider&&v.accessibilityProvider.isChecked?e=>v.accessibilityProvider.isChecked(e.element):void 0,getRole:v.accessibilityProvider&&v.accessibilityProvider.getRole?e=>v.accessibilityProvider.getRole(e.element):()=>"treeitem",getAriaLabel:e=>v.accessibilityProvider.getAriaLabel(e.element),getWidgetAriaLabel:()=>v.accessibilityProvider.getWidgetAriaLabel(),getWidgetRole:v.accessibilityProvider&&v.accessibilityProvider.getWidgetRole?()=>v.accessibilityProvider.getWidgetRole():()=>"tree",getAriaLevel:v.accessibilityProvider&&v.accessibilityProvider.getAriaLevel?e=>v.accessibilityProvider.getAriaLevel(e.element):e=>e.depth,getActiveDescendantId:v.accessibilityProvider.getActiveDescendantId&&(e=>v.accessibilityProvider.getActiveDescendantId(e.element))},keyboardNavigationLabelProvider:v.keyboardNavigationLabelProvider&&{...v.keyboardNavigationLabelProvider,getKeyboardNavigationLabel:e=>v.keyboardNavigationLabelProvider.getKeyboardNavigationLabel(e.element)}}),tree:this,stickyScrollProvider:()=>this.stickyScrollController}),this.model=this.createModel(e,this.view,a),c.input=this.model.onDidChangeCollapseState;const b=_.Jh.forEach(this.model.onDidSplice,(e=>{this.eventBufferer.bufferEvents((()=>{this.focus.onDidModelSplice(e),this.selection.onDidModelSplice(e)}))}),this.disposables);b((()=>null),null,this.disposables);const E=this.disposables.add(new _.vl),S=this.disposables.add(new g.ve(0));if(this.disposables.add(_.Jh.any(b,this.focus.onDidChange,this.selection.onDidChange)((()=>{S.trigger((()=>{const e=new Set;for(const t of this.focus.getNodes())e.add(t);for(const t of this.selection.getNodes())e.add(t);E.fire([...e.values()])}))}))),h.input=E.event,!1!==a.keyboardSupport){const e=_.Jh.chain(this.view.onKeyDown,(e=>e.filter((e=>!(0,l.B6)(e.target))).map((e=>new r.Z(e)))));_.Jh.chain(e,(e=>e.filter((e=>15===e.keyCode))))(this.onLeftArrow,this,this.disposables),_.Jh.chain(e,(e=>e.filter((e=>17===e.keyCode))))(this.onRightArrow,this,this.disposables),_.Jh.chain(e,(e=>e.filter((e=>10===e.keyCode))))(this.onSpace,this,this.disposables)}if((a.findWidgetEnabled??1)&&a.keyboardNavigationLabelProvider&&a.contextViewProvider){const e=this.options.findWidgetStyles?{styles:this.options.findWidgetStyles}:void 0;this.findController=new D(this,this.model,this.view,p,a.contextViewProvider,e),this.focusNavigationFilter=e=>this.findController.shouldAllowFocus(e),this.onDidChangeFindOpenState=this.findController.onDidChangeOpenState,this.disposables.add(this.findController),this.onDidChangeFindMode=this.findController.onDidChangeMode,this.onDidChangeFindMatchType=this.findController.onDidChangeMatchType}else this.onDidChangeFindMode=_.Jh.None,this.onDidChangeFindMatchType=_.Jh.None;a.enableStickyScroll&&(this.stickyScrollController=new H(this,this.model,this.view,this.renderers,this.treeDelegate,a),this.onDidChangeStickyScrollFocused=this.stickyScrollController.onDidChangeHasFocus),this.styleElement=(0,n.li)(this.view.getHTMLElement()),this.getHTMLElement().classList.toggle("always",this._options.renderIndentGuides===s.Always)}updateOptions(e={}){this._options={...this._options,...e};for(const t of this.renderers)t.updateOptions(e);this.view.updateOptions(this._options),this.findController?.updateOptions(e),this.updateStickyScroll(e),this._onDidUpdateOptions.fire(this._options),this.getHTMLElement().classList.toggle("always",this._options.renderIndentGuides===s.Always)}get options(){return this._options}updateStickyScroll(e){!this.stickyScrollController&&this._options.enableStickyScroll?(this.stickyScrollController=new H(this,this.model,this.view,this.renderers,this.treeDelegate,this._options),this.onDidChangeStickyScrollFocused=this.stickyScrollController.onDidChangeHasFocus):this.stickyScrollController&&!this._options.enableStickyScroll&&(this.onDidChangeStickyScrollFocused=_.Jh.None,this.stickyScrollController.dispose(),this.stickyScrollController=void 0),this.stickyScrollController?.updateOptions(e)}getHTMLElement(){return this.view.getHTMLElement()}get scrollTop(){return this.view.scrollTop}set scrollTop(e){this.view.scrollTop=e}get scrollHeight(){return this.view.scrollHeight}get renderHeight(){return this.view.renderHeight}get ariaLabel(){return this.view.ariaLabel}set ariaLabel(e){this.view.ariaLabel=e}domFocus(){this.stickyScrollController?.focusedLast()?this.stickyScrollController.domFocus():this.view.domFocus()}layout(e,t){this.view.layout(e,t),(0,E.Et)(t)&&this.findController?.layout(t)}style(e){const t=`.${this.view.domId}`,i=[];e.treeIndentGuidesStroke&&(i.push(`.monaco-list${t}:hover .monaco-tl-indent > .indent-guide, .monaco-list${t}.always .monaco-tl-indent > .indent-guide { border-color: ${e.treeInactiveIndentGuidesStroke}; }`),i.push(`.monaco-list${t} .monaco-tl-indent > .indent-guide.active { border-color: ${e.treeIndentGuidesStroke}; }`));const s=e.treeStickyScrollBackground??e.listBackground;s&&(i.push(`.monaco-list${t} .monaco-scrollable-element .monaco-tree-sticky-container { background-color: ${s}; }`),i.push(`.monaco-list${t} .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-row { background-color: ${s}; }`)),e.treeStickyScrollBorder&&i.push(`.monaco-list${t} .monaco-scrollable-element .monaco-tree-sticky-container { border-bottom: 1px solid ${e.treeStickyScrollBorder}; }`),e.treeStickyScrollShadow&&i.push(`.monaco-list${t} .monaco-scrollable-element .monaco-tree-sticky-container .monaco-tree-sticky-container-shadow { box-shadow: ${e.treeStickyScrollShadow} 0 6px 6px -6px inset; height: 3px; }`),e.listFocusForeground&&(i.push(`.monaco-list${t}.sticky-scroll-focused .monaco-scrollable-element .monaco-tree-sticky-container:focus .monaco-list-row.focused { color: ${e.listFocusForeground}; }`),i.push(`.monaco-list${t}:not(.sticky-scroll-focused) .monaco-scrollable-element .monaco-tree-sticky-container .monaco-list-row.focused { color: inherit; }`));const r=(0,n.gI)(e.listFocusAndSelectionOutline,(0,n.gI)(e.listSelectionOutline,e.listFocusOutline??""));r&&(i.push(`.monaco-list${t}.sticky-scroll-focused .monaco-scrollable-element .monaco-tree-sticky-container:focus .monaco-list-row.focused.selected { outline: 1px solid ${r}; outline-offset: -1px;}`),i.push(`.monaco-list${t}:not(.sticky-scroll-focused) .monaco-scrollable-element .monaco-tree-sticky-container .monaco-list-row.focused.selected { outline: inherit;}`)),e.listFocusOutline&&(i.push(`.monaco-list${t}.sticky-scroll-focused .monaco-scrollable-element .monaco-tree-sticky-container:focus .monaco-list-row.focused { outline: 1px solid ${e.listFocusOutline}; outline-offset: -1px; }`),i.push(`.monaco-list${t}:not(.sticky-scroll-focused) .monaco-scrollable-element .monaco-tree-sticky-container .monaco-list-row.focused { outline: inherit; }`),i.push(`.monaco-workbench.context-menu-visible .monaco-list${t}.last-focused.sticky-scroll-focused .monaco-scrollable-element .monaco-tree-sticky-container .monaco-list-row.passive-focused { outline: 1px solid ${e.listFocusOutline}; outline-offset: -1px; }`),i.push(`.monaco-workbench.context-menu-visible .monaco-list${t}.last-focused.sticky-scroll-focused .monaco-list-rows .monaco-list-row.focused { outline: inherit; }`),i.push(`.monaco-workbench.context-menu-visible .monaco-list${t}.last-focused:not(.sticky-scroll-focused) .monaco-tree-sticky-container .monaco-list-rows .monaco-list-row.focused { outline: inherit; }`)),this.styleElement.textContent=i.join("\n"),this.view.style(e)}getParentElement(e){const t=this.model.getParentNodeLocation(e);return this.model.getNode(t).element}getFirstElementChild(e){return this.model.getFirstElementChild(e)}getNode(e){return this.model.getNode(e)}getNodeLocation(e){return this.model.getNodeLocation(e)}collapse(e,t=!1){return this.model.setCollapsed(e,!0,t)}expand(e,t=!1){return this.model.setCollapsed(e,!1,t)}toggleCollapsed(e,t=!1){return this.model.setCollapsed(e,void 0,t)}isCollapsible(e){return this.model.isCollapsible(e)}setCollapsible(e,t){return this.model.setCollapsible(e,t)}isCollapsed(e){return this.model.isCollapsed(e)}refilter(){this._onWillRefilter.fire(void 0),this.model.refilter()}setSelection(e,t){this.eventBufferer.bufferEvents((()=>{const i=e.map((e=>this.model.getNode(e)));this.selection.set(i,t);const s=e.map((e=>this.model.getListIndex(e))).filter((e=>e>-1));this.view.setSelection(s,t,!0)}))}getSelection(){return this.selection.get()}setFocus(e,t){this.eventBufferer.bufferEvents((()=>{const i=e.map((e=>this.model.getNode(e)));this.focus.set(i,t);const s=e.map((e=>this.model.getListIndex(e))).filter((e=>e>-1));this.view.setFocus(s,t,!0)}))}focusNext(e=1,t=!1,i,s=((0,n.kx)(i)&&i.altKey?void 0:this.focusNavigationFilter)){this.view.focusNext(e,t,i,s)}focusPrevious(e=1,t=!1,i,s=((0,n.kx)(i)&&i.altKey?void 0:this.focusNavigationFilter)){this.view.focusPrevious(e,t,i,s)}focusNextPage(e,t=((0,n.kx)(e)&&e.altKey?void 0:this.focusNavigationFilter)){return this.view.focusNextPage(e,t)}focusPreviousPage(e,t=((0,n.kx)(e)&&e.altKey?void 0:this.focusNavigationFilter)){return this.view.focusPreviousPage(e,t,(()=>this.stickyScrollController?.height??0))}focusLast(e,t=((0,n.kx)(e)&&e.altKey?void 0:this.focusNavigationFilter)){this.view.focusLast(e,t)}focusFirst(e,t=((0,n.kx)(e)&&e.altKey?void 0:this.focusNavigationFilter)){this.view.focusFirst(e,t)}getFocus(){return this.focus.get()}reveal(e,t){this.model.expandTo(e);const i=this.model.getListIndex(e);if(-1!==i)if(this.stickyScrollController){const s=this.stickyScrollController.nodePositionTopBelowWidget(this.getNode(e));this.view.reveal(i,t,s)}else this.view.reveal(i,t)}onLeftArrow(e){e.preventDefault(),e.stopPropagation();const t=this.view.getFocusedElements();if(0===t.length)return;const i=t[0],s=this.model.getNodeLocation(i);if(!this.model.setCollapsed(s,!0)){const e=this.model.getParentNodeLocation(s);if(!e)return;const t=this.model.getListIndex(e);this.view.reveal(t),this.view.setFocus([t])}}onRightArrow(e){e.preventDefault(),e.stopPropagation();const t=this.view.getFocusedElements();if(0===t.length)return;const i=t[0],s=this.model.getNodeLocation(i);if(!this.model.setCollapsed(s,!1)){if(!i.children.some((e=>e.visible)))return;const[e]=this.view.getFocus(),t=e+1;this.view.reveal(t),this.view.setFocus([t])}}onSpace(e){e.preventDefault(),e.stopPropagation();const t=this.view.getFocusedElements();if(0===t.length)return;const i=t[0],s=this.model.getNodeLocation(i),n=e.browserEvent.altKey;this.model.setCollapsed(s,void 0,n)}dispose(){(0,C.AS)(this.disposables),this.stickyScrollController?.dispose(),this.view.dispose()}}},37472:(e,t,i)=>{"use strict";i.d(t,{G6:()=>g,Mn:()=>d,iZ:()=>h});var s=i(84565),n=i(25890),r=i(90766),o=i(44759),a=i(83993),l=i(41234),c=i(42522);function h(e){return"object"===typeof e&&"visibility"in e&&"data"in e}function d(e){switch(e){case!0:return 1;case!1:return 0;default:return e}}function u(e){return"boolean"===typeof e.collapsible}class g{constructor(e,t,i,s={}){this.user=e,this.list=t,this.rootRef=[],this.eventBufferer=new l.at,this._onDidChangeCollapseState=new l.vl,this.onDidChangeCollapseState=this.eventBufferer.wrapEvent(this._onDidChangeCollapseState.event),this._onDidChangeRenderNodeCount=new l.vl,this.onDidChangeRenderNodeCount=this.eventBufferer.wrapEvent(this._onDidChangeRenderNodeCount.event),this._onDidSplice=new l.vl,this.onDidSplice=this._onDidSplice.event,this.refilterDelayer=new r.ve(o.h),this.collapseByDefault="undefined"!==typeof s.collapseByDefault&&s.collapseByDefault,this.allowNonCollapsibleParents=s.allowNonCollapsibleParents??!1,this.filter=s.filter,this.autoExpandSingleChildren="undefined"!==typeof s.autoExpandSingleChildren&&s.autoExpandSingleChildren,this.root={parent:void 0,element:i,children:[],depth:0,visibleChildrenCount:0,visibleChildIndex:-1,collapsible:!1,collapsed:!1,renderNodeCount:0,visibility:1,visible:!0,filterData:void 0}}splice(e,t,i=c.f.empty(),n={}){if(0===e.length)throw new s.jh(this.user,"Invalid tree location");n.diffIdentityProvider?this.spliceSmart(n.diffIdentityProvider,e,t,i,n):this.spliceSimple(e,t,i,n)}spliceSmart(e,t,i,s=c.f.empty(),n,r=n.diffDepth??0){const{parentNode:o}=this.getParentNodeWithListIndex(t);if(!o.lastDiffIds)return this.spliceSimple(t,i,s,n);const l=[...s],h=t[t.length-1],d=new a.uP({getElements:()=>o.lastDiffIds},{getElements:()=>[...o.children.slice(0,h),...l,...o.children.slice(h+i)].map((t=>e.getId(t.element).toString()))}).ComputeDiff(!1);if(d.quitEarly)return o.lastDiffIds=void 0,this.spliceSimple(t,i,l,n);const u=t.slice(0,-1),g=(t,i,s)=>{if(r>0)for(let o=0;ot.originalStart-e.originalStart)))g(p,m,p-(a.originalStart+a.originalLength)),p=a.originalStart,m=a.modifiedStart-h,this.spliceSimple([...u,p],a.originalLength,c.f.slice(l,m,m+a.modifiedLength),n);g(p,m,p)}spliceSimple(e,t,i=c.f.empty(),{onDidCreateNode:s,onDidDeleteNode:r,diffIdentityProvider:o}){const{parentNode:a,listIndex:l,revealed:h,visible:d}=this.getParentNodeWithListIndex(e),u=[],g=c.f.map(i,(e=>this.createTreeNode(e,a,a.visible?1:0,h,u,s))),p=e[e.length-1];let m=0;for(let n=p;n>=0&&no.getId(e.element).toString()))):a.lastDiffIds=a.children.map((e=>o.getId(e.element).toString())):a.lastDiffIds=void 0;let b=0;for(const n of C)n.visible&&b++;if(0!==b)for(let n=p+f.length;ne+(t.visible?t.renderNodeCount:0)),0);this._updateAncestorsRenderNodeCount(a,v-e),this.list.splice(l,e,u)}if(C.length>0&&r){const e=t=>{r(t),t.children.forEach(e)};C.forEach(e)}this._onDidSplice.fire({insertedNodes:f,deletedNodes:C});let E=a;for(;E;){if(2===E.visibility){this.refilterDelayer.trigger((()=>this.refilter()));break}E=E.parent}}rerender(e){if(0===e.length)throw new s.jh(this.user,"Invalid tree location");const{node:t,listIndex:i,revealed:n}=this.getTreeNodeWithListIndex(e);t.visible&&n&&this.list.splice(i,1,[t])}has(e){return this.hasTreeNode(e)}getListIndex(e){const{listIndex:t,visible:i,revealed:s}=this.getTreeNodeWithListIndex(e);return i&&s?t:-1}getListRenderCount(e){return this.getTreeNode(e).renderNodeCount}isCollapsible(e){return this.getTreeNode(e).collapsible}setCollapsible(e,t){const i=this.getTreeNode(e);"undefined"===typeof t&&(t=!i.collapsible);const s={collapsible:t};return this.eventBufferer.bufferEvents((()=>this._setCollapseState(e,s)))}isCollapsed(e){return this.getTreeNode(e).collapsed}setCollapsed(e,t,i){const s=this.getTreeNode(e);"undefined"===typeof t&&(t=!s.collapsed);const n={collapsed:t,recursive:i||!1};return this.eventBufferer.bufferEvents((()=>this._setCollapseState(e,n)))}_setCollapseState(e,t){const{node:i,listIndex:s,revealed:n}=this.getTreeNodeWithListIndex(e),r=this._setListNodeCollapseState(i,s,n,t);if(i!==this.root&&this.autoExpandSingleChildren&&r&&!u(t)&&i.collapsible&&!i.collapsed&&!t.recursive){let s=-1;for(let e=0;e-1){s=-1;break}s=e}}s>-1&&this._setCollapseState([...e,s],t)}return r}_setListNodeCollapseState(e,t,i,s){const n=this._setNodeCollapseState(e,s,!1);if(!i||!e.visible||!n)return n;const r=e.renderNodeCount,o=this.updateNodeAfterCollapseChange(e),a=r-(-1===t?0:1);return this.list.splice(t+1,a,o.slice(1)),n}_setNodeCollapseState(e,t,i){let s;if(e===this.root?s=!1:(u(t)?(s=e.collapsible!==t.collapsible,e.collapsible=t.collapsible):e.collapsible?(s=e.collapsed!==t.collapsed,e.collapsed=t.collapsed):s=!1,s&&this._onDidChangeCollapseState.fire({node:e,deep:i})),!u(t)&&t.recursive)for(const n of e.children)s=this._setNodeCollapseState(n,t,!0)||s;return s}expandTo(e){this.eventBufferer.bufferEvents((()=>{let t=this.getTreeNode(e);for(;t.parent;)t=t.parent,e=e.slice(0,e.length-1),t.collapsed&&this._setCollapseState(e,{collapsed:!1,recursive:!1})}))}refilter(){const e=this.root.renderNodeCount,t=this.updateNodeAfterFilterChange(this.root);this.list.splice(0,e,t),this.refilterDelayer.cancel()}createTreeNode(e,t,i,s,n,r){const o={parent:t,element:e.element,children:[],depth:t.depth+1,visibleChildrenCount:0,visibleChildIndex:-1,collapsible:"boolean"===typeof e.collapsible?e.collapsible:"undefined"!==typeof e.collapsed,collapsed:"undefined"===typeof e.collapsed?this.collapseByDefault:e.collapsed,renderNodeCount:1,visibility:1,visible:!0,filterData:void 0},a=this._filterNode(o,i);o.visibility=a,s&&n.push(o);const l=e.children||c.f.empty(),h=s&&0!==a&&!o.collapsed;let d=0,u=1;for(const c of l){const e=this.createTreeNode(c,o,a,h,n,r);o.children.push(e),u+=e.renderNodeCount,e.visible&&(e.visibleChildIndex=d++)}return this.allowNonCollapsibleParents||(o.collapsible=o.collapsible||o.children.length>0),o.visibleChildrenCount=d,o.visible=2===a?d>0:1===a,o.visible?o.collapsed||(o.renderNodeCount=u):(o.renderNodeCount=0,s&&n.pop()),r?.(o),o}updateNodeAfterCollapseChange(e){const t=e.renderNodeCount,i=[];return this._updateNodeAfterCollapseChange(e,i),this._updateAncestorsRenderNodeCount(e.parent,i.length-t),i}_updateNodeAfterCollapseChange(e,t){if(!1===e.visible)return 0;if(t.push(e),e.renderNodeCount=1,!e.collapsed)for(const i of e.children)e.renderNodeCount+=this._updateNodeAfterCollapseChange(i,t);return this._onDidChangeRenderNodeCount.fire(e),e.renderNodeCount}updateNodeAfterFilterChange(e){const t=e.renderNodeCount,i=[];return this._updateNodeAfterFilterChange(e,e.visible?1:0,i),this._updateAncestorsRenderNodeCount(e.parent,i.length-t),i}_updateNodeAfterFilterChange(e,t,i,s=!0){let n;if(e!==this.root){if(n=this._filterNode(e,t),0===n)return e.visible=!1,e.renderNodeCount=0,!1;s&&i.push(e)}const r=i.length;e.renderNodeCount=e===this.root?0:1;let o=!1;if(e.collapsed&&0===n)e.visibleChildrenCount=0;else{let t=0;for(const r of e.children)o=this._updateNodeAfterFilterChange(r,n,i,s&&!e.collapsed)||o,r.visible&&(r.visibleChildIndex=t++);e.visibleChildrenCount=t}return e!==this.root&&(e.visible=2===n?o:1===n,e.visibility=n),e.visible?e.collapsed||(e.renderNodeCount+=i.length-r):(e.renderNodeCount=0,s&&i.pop()),this._onDidChangeRenderNodeCount.fire(e),e.visible}_updateAncestorsRenderNodeCount(e,t){if(0!==t)for(;e;)e.renderNodeCount+=t,this._onDidChangeRenderNodeCount.fire(e),e=e.parent}_filterNode(e,t){const i=this.filter?this.filter.filter(e.element,t):1;return"boolean"===typeof i?(e.filterData=void 0,i?1:0):h(i)?(e.filterData=i.data,d(i.visibility)):(e.filterData=void 0,d(i))}hasTreeNode(e,t=this.root){if(!e||0===e.length)return!0;const[i,...s]=e;return!(i<0||i>t.children.length)&&this.hasTreeNode(s,t.children[i])}getTreeNode(e,t=this.root){if(!e||0===e.length)return t;const[i,...n]=e;if(i<0||i>t.children.length)throw new s.jh(this.user,"Invalid tree location");return this.getTreeNode(n,t.children[i])}getTreeNodeWithListIndex(e){if(0===e.length)return{node:this.root,listIndex:-1,revealed:!0,visible:!1};const{parentNode:t,listIndex:i,revealed:n,visible:r}=this.getParentNodeWithListIndex(e),o=e[e.length-1];if(o<0||o>t.children.length)throw new s.jh(this.user,"Invalid tree location");const a=t.children[o];return{node:a,listIndex:i,revealed:n,visible:r&&a.visible}}getParentNodeWithListIndex(e,t=this.root,i=0,n=!0,r=!0){const[o,...a]=e;if(o<0||o>t.children.length)throw new s.jh(this.user,"Invalid tree location");for(let s=0;s{"use strict";var s,n;i.d(t,{Lx:()=>n,Yo:()=>s,jh:()=>r,y2:()=>o}),function(e){e[e.Expanded=0]="Expanded",e[e.Collapsed=1]="Collapsed",e[e.PreserveOrExpanded=2]="PreserveOrExpanded",e[e.PreserveOrCollapsed=3]="PreserveOrCollapsed"}(s||(s={})),function(e){e[e.Unknown=0]="Unknown",e[e.Twistie=1]="Twistie",e[e.Element=2]="Element",e[e.Filter=3]="Filter"}(n||(n={}));class r extends Error{constructor(e,t){super(`TreeError [${e}] ${t}`)}}class o{constructor(e){this.fn=e,this._map=new WeakMap}map(e){let t=this._map.get(e);return t||(t=this.fn(e),this._map.set(e,t)),t}}},17390:(e,t,i)=>{"use strict";i.d(t,{x:()=>l});var s=i(8597),n=i(72962),r=i(47358),o=i(25154),a=i(5662);class l extends a.jG{onclick(e,t){this._register(s.ko(e,s.Bx.CLICK,(i=>t(new r.P(s.zk(e),i)))))}onmousedown(e,t){this._register(s.ko(e,s.Bx.MOUSE_DOWN,(i=>t(new r.P(s.zk(e),i)))))}onmouseover(e,t){this._register(s.ko(e,s.Bx.MOUSE_OVER,(i=>t(new r.P(s.zk(e),i)))))}onmouseleave(e,t){this._register(s.ko(e,s.Bx.MOUSE_LEAVE,(i=>t(new r.P(s.zk(e),i)))))}onkeydown(e,t){this._register(s.ko(e,s.Bx.KEY_DOWN,(e=>t(new n.Z(e)))))}onkeyup(e,t){this._register(s.ko(e,s.Bx.KEY_UP,(e=>t(new n.Z(e)))))}oninput(e,t){this._register(s.ko(e,s.Bx.INPUT,t))}onblur(e,t){this._register(s.ko(e,s.Bx.BLUR,t))}onfocus(e,t){this._register(s.ko(e,s.Bx.FOCUS,t))}ignoreGesture(e){return o.q.ignoreTarget(e)}}},25893:(e,t,i)=>{"use strict";function s(e,t){const i=e;"number"!==typeof i.vscodeWindowId&&Object.defineProperty(i,"vscodeWindowId",{get:()=>t})}i.d(t,{G:()=>n,y:()=>s});const n=window},36921:(e,t,i)=>{"use strict";i.d(t,{HJ:()=>h,LN:()=>a,YH:()=>c,ih:()=>d,rc:()=>o,wv:()=>l});var s=i(41234),n=i(5662),r=i(78209);class o extends n.jG{constructor(e,t="",i="",n=!0,r){super(),this._onDidChange=this._register(new s.vl),this.onDidChange=this._onDidChange.event,this._enabled=!0,this._id=e,this._label=t,this._cssClass=i,this._enabled=n,this._actionCallback=r}get id(){return this._id}get label(){return this._label}set label(e){this._setLabel(e)}_setLabel(e){this._label!==e&&(this._label=e,this._onDidChange.fire({label:e}))}get tooltip(){return this._tooltip||""}set tooltip(e){this._setTooltip(e)}_setTooltip(e){this._tooltip!==e&&(this._tooltip=e,this._onDidChange.fire({tooltip:e}))}get class(){return this._cssClass}set class(e){this._setClass(e)}_setClass(e){this._cssClass!==e&&(this._cssClass=e,this._onDidChange.fire({class:e}))}get enabled(){return this._enabled}set enabled(e){this._setEnabled(e)}_setEnabled(e){this._enabled!==e&&(this._enabled=e,this._onDidChange.fire({enabled:e}))}get checked(){return this._checked}set checked(e){this._setChecked(e)}_setChecked(e){this._checked!==e&&(this._checked=e,this._onDidChange.fire({checked:e}))}async run(e,t){this._actionCallback&&await this._actionCallback(e)}}class a extends n.jG{constructor(){super(...arguments),this._onWillRun=this._register(new s.vl),this.onWillRun=this._onWillRun.event,this._onDidRun=this._register(new s.vl),this.onDidRun=this._onDidRun.event}async run(e,t){if(!e.enabled)return;let i;this._onWillRun.fire({action:e});try{await this.runAction(e,t)}catch(s){i=s}this._onDidRun.fire({action:e,error:i})}async runAction(e,t){await e.run(t)}}class l{constructor(){this.id=l.ID,this.label="",this.tooltip="",this.class="separator",this.enabled=!1,this.checked=!1}static join(...e){let t=[];for(const i of e)i.length&&(t=t.length?[...t,new l,...i]:i);return t}static{this.ID="vs.actions.separator"}async run(){}}class c{get actions(){return this._actions}constructor(e,t,i,s){this.tooltip="",this.enabled=!0,this.checked=void 0,this.id=e,this.label=t,this.class=s,this._actions=i}async run(){}}class h extends o{static{this.ID="vs.actions.empty"}constructor(){super(h.ID,r.kg("submenu.empty","(empty)"),void 0,!1)}}function d(e){return{id:e.id,label:e.label,tooltip:e.tooltip??e.label,class:e.class,enabled:e.enabled??!0,checked:e.checked,run:async(...t)=>e.run(...t)}}},25890:(e,t,i)=>{"use strict";function s(e,t=0){return e[e.length-(1+t)]}function n(e){if(0===e.length)throw new Error("Invalid tail call");return[e.slice(0,e.length-1),e[e.length-1]]}function r(e,t,i=(e,t)=>e===t){if(e===t)return!0;if(!e||!t)return!1;if(e.length!==t.length)return!1;for(let s=0,n=e.length;s0))return e;s=e-1}}return-(i+1)}(e.length,(s=>i(e[s],t)))}function l(e,t,i){if((e|=0)>=t.length)throw new TypeError("invalid index");const s=t[Math.floor(t.length*Math.random())],n=[],r=[],o=[];for(const a of t){const e=i(a,s);e<0?n.push(a):e>0?r.push(a):o.push(a)}return e!!e))}function p(e){let t=0;for(let i=0;i0}function _(e,t=e=>e){const i=new Set;return e.filter((e=>{const s=t(e);return!i.has(s)&&(i.add(s),!0)}))}function v(e,t){return e.length>0?e[0]:t}function C(e,t){let i="number"===typeof t?e:0;"number"===typeof t?i=e:(i=0,t=e);const s=[];if(i<=t)for(let n=i;nt;n--)s.push(n);return s}function b(e,t,i){const s=e.slice(0,t),n=e.slice(t);return s.concat(i,n)}function E(e,t){const i=e.indexOf(t);i>-1&&(e.splice(i,1),e.unshift(t))}function S(e,t){const i=e.indexOf(t);i>-1&&(e.splice(i,1),e.push(t))}function y(e,t){for(const i of t)e.push(i)}function w(e){return Array.isArray(e)?e:[e]}function L(e,t,i,s){const n=R(e,t);let r=e.splice(n,i);return void 0===r&&(r=[]),function(e,t,i){const s=R(e,t),n=e.length,r=i.length;e.length=n+r;for(let o=n-1;o>=s;o--)e[o+r]=e[o];for(let o=0;ot(e(i),e(s))}function k(...e){return(t,i)=>{for(const s of e){const e=s(t,i);if(!T.isNeitherLessOrGreaterThan(e))return e}return T.neitherLessOrGreaterThan}}i.d(t,{$z:()=>c,Ct:()=>m,E4:()=>y,EI:()=>f,El:()=>a,Fy:()=>v,Hw:()=>I,RT:()=>s,SK:()=>p,SO:()=>l,TS:()=>N,U9:()=>A,UH:()=>o,V4:()=>L,VE:()=>x,Yc:()=>g,_A:()=>E,_j:()=>w,aI:()=>r,bS:()=>n,c1:()=>D,dM:()=>_,j3:()=>O,kj:()=>u,n:()=>h,nH:()=>k,nK:()=>b,pN:()=>d,r7:()=>S,t9:()=>M,y1:()=>C}),function(e){e.isLessThan=function(e){return e<0},e.isLessThanOrEqual=function(e){return e<=0},e.isGreaterThan=function(e){return e>0},e.isNeitherLessOrGreaterThan=function(e){return 0===e},e.greaterThan=1,e.lessThan=-1,e.neitherLessOrGreaterThan=0}(T||(T={}));const A=(e,t)=>e-t,N=(e,t)=>A(e?1:0,t?1:0);function I(e){return(t,i)=>-e(t,i)}class O{constructor(e){this.items=e,this.firstIdx=0,this.lastIdx=this.items.length-1}get length(){return this.lastIdx-this.firstIdx+1}takeWhile(e){let t=this.firstIdx;for(;t=0&&e(this.items[t]);)t--;const i=t===this.lastIdx?null:this.items.slice(t+1,this.lastIdx+1);return this.lastIdx=t,i}peek(){if(0!==this.length)return this.items[this.firstIdx]}dequeue(){const e=this.items[this.firstIdx];return this.firstIdx++,e}takeCount(e){const t=this.items.slice(this.firstIdx,this.firstIdx+e);return this.firstIdx+=e,t}}class D{static{this.empty=new D((e=>{}))}constructor(e){this.iterate=e}toArray(){const e=[];return this.iterate((t=>(e.push(t),!0))),e}filter(e){return new D((t=>this.iterate((i=>!e(i)||t(i)))))}map(e){return new D((t=>this.iterate((i=>t(e(i))))))}findLast(e){let t;return this.iterate((i=>(e(i)&&(t=i),!0))),t}findLastMaxBy(e){let t,i=!0;return this.iterate((s=>((i||T.isGreaterThan(e(s,t)))&&(i=!1,t=s),!0))),t}}class M{constructor(e){this._indexMap=e}static createSortPermutation(e,t){const i=Array.from(e.keys()).sort(((i,s)=>t(e[i],e[s])));return new M(i)}apply(e){return e.map(((t,i)=>e[this._indexMap[i]]))}inverse(){const e=this._indexMap.slice();for(let t=0;t{"use strict";function s(e,t){const i=function(e,t,i=e.length-1){for(let s=i;s>=0;s--){if(t(e[s]))return s}return-1}(e,t);if(-1!==i)return e[i]}function n(e,t){const i=r(e,t);return-1===i?void 0:e[i]}function r(e,t,i=0,s=e.length){let n=i,r=s;for(;nc,TM:()=>u,Uk:()=>s,XP:()=>o,hw:()=>a,iM:()=>r,kh:()=>d,lx:()=>n,oH:()=>g,ot:()=>h,vJ:()=>l});class l{static{this.assertInvariants=!1}constructor(e){this._array=e,this._findLastMonotonousLastIdx=0}findLastMonotonous(e){if(l.assertInvariants){if(this._prevFindLastPredicate)for(const t of this._array)if(this._prevFindLastPredicate(t)&&!e(t))throw new Error("MonotonousArray: current predicate must be weaker than (or equal to) the previous predicate.");this._prevFindLastPredicate=e}const t=r(this._array,e,this._findLastMonotonousLastIdx);return this._findLastMonotonousLastIdx=t+1,-1===t?void 0:this._array[t]}}function c(e,t){if(0===e.length)return;let i=e[0];for(let s=1;s0&&(i=n)}return i}function h(e,t){if(0===e.length)return;let i=e[0];for(let s=1;s=0&&(i=n)}return i}function d(e,t){return c(e,((e,i)=>-t(e,i)))}function u(e,t){if(0===e.length)return-1;let i=0;for(let s=1;s0&&(i=s)}return i}function g(e,t){for(const i of e){const e=t(i);if(void 0!==e)return e}}},66782:(e,t,i)=>{"use strict";i.d(t,{Ft:()=>a,V7:()=>o,Xo:()=>l,ok:()=>n,xb:()=>r});var s=i(64383);function n(e,t){if(!e)throw new Error(t?`Assertion failed (${t})`:"Assertion Failed")}function r(e,t="Unreachable"){throw new Error(t)}function o(e){e||(0,s.dz)(new s.D7("Soft Assertion Failed"))}function a(e){e()||(e(),(0,s.dz)(new s.D7("Assertion Failed")))}function l(e,t){let i=0;for(;i{"use strict";i.d(t,{$1:()=>_,$6:()=>E,A0:()=>y,AE:()=>T,EQ:()=>f,F6:()=>w,HC:()=>R,PK:()=>d,Qg:()=>c,SS:()=>h,Th:()=>p,Zv:()=>L,b7:()=>S,bI:()=>k,pc:()=>v,uC:()=>b,vb:()=>C,ve:()=>g,wR:()=>m});var s=i(18447),n=i(64383),r=i(41234),o=i(5662),a=i(98067),l=i(44759);function c(e){return!!e&&"function"===typeof e.then}function h(e){const t=new s.Qi,i=e(t.token),r=new Promise(((e,s)=>{const r=t.token.onCancellationRequested((()=>{r.dispose(),s(new n.AL)}));Promise.resolve(i).then((i=>{r.dispose(),t.dispose(),e(i)}),(e=>{r.dispose(),t.dispose(),s(e)}))}));return new class{cancel(){t.cancel(),t.dispose()}then(e,t){return r.then(e,t)}catch(e){return this.then(void 0,e)}finally(e){return r.finally(e)}}}function d(e,t,i){return new Promise(((s,n)=>{const r=t.onCancellationRequested((()=>{r.dispose(),s(i)}));e.then(s,n).finally((()=>r.dispose()))}))}class u{constructor(){this.isDisposed=!1,this.activePromise=null,this.queuedPromise=null,this.queuedPromiseFactory=null}queue(e){if(this.isDisposed)return Promise.reject(new Error("Throttler is disposed"));if(this.activePromise){if(this.queuedPromiseFactory=e,!this.queuedPromise){const e=()=>{if(this.queuedPromise=null,this.isDisposed)return;const e=this.queue(this.queuedPromiseFactory);return this.queuedPromiseFactory=null,e};this.queuedPromise=new Promise((t=>{this.activePromise.then(e,e).then(t)}))}return new Promise(((e,t)=>{this.queuedPromise.then(e,t)}))}return this.activePromise=e(),new Promise(((e,t)=>{this.activePromise.then((t=>{this.activePromise=null,e(t)}),(e=>{this.activePromise=null,t(e)}))}))}dispose(){this.isDisposed=!0}}class g{constructor(e){this.defaultDelay=e,this.deferred=null,this.completionPromise=null,this.doResolve=null,this.doReject=null,this.task=null}trigger(e,t=this.defaultDelay){this.task=e,this.cancelTimeout(),this.completionPromise||(this.completionPromise=new Promise(((e,t)=>{this.doResolve=e,this.doReject=t})).then((()=>{if(this.completionPromise=null,this.doResolve=null,this.task){const e=this.task;return this.task=null,e()}})));const i=()=>{this.deferred=null,this.doResolve?.(null)};return this.deferred=t===l.h?(e=>{let t=!0;return queueMicrotask((()=>{t&&(t=!1,e())})),{isTriggered:()=>t,dispose:()=>{t=!1}}})(i):((e,t)=>{let i=!0;const s=setTimeout((()=>{i=!1,t()}),e);return{isTriggered:()=>i,dispose:()=>{clearTimeout(s),i=!1}}})(t,i),this.completionPromise}isTriggered(){return!!this.deferred?.isTriggered()}cancel(){this.cancelTimeout(),this.completionPromise&&(this.doReject?.(new n.AL),this.completionPromise=null)}cancelTimeout(){this.deferred?.dispose(),this.deferred=null}dispose(){this.cancel()}}class p{constructor(e){this.delayer=new g(e),this.throttler=new u}trigger(e,t){return this.delayer.trigger((()=>this.throttler.queue(e)),t)}cancel(){this.delayer.cancel()}dispose(){this.delayer.dispose(),this.throttler.dispose()}}function m(e,t){return t?new Promise(((i,s)=>{const r=setTimeout((()=>{o.dispose(),i()}),e),o=t.onCancellationRequested((()=>{clearTimeout(r),o.dispose(),s(new n.AL)}))})):h((t=>m(e,t)))}function f(e,t=0,i){const s=setTimeout((()=>{e(),i&&n.dispose()}),t),n=(0,o.s)((()=>{clearTimeout(s),i?.deleteAndLeak(n)}));return i?.add(n),n}function _(e,t=e=>!!e,i=null){let s=0;const n=e.length,r=()=>{if(s>=n)return Promise.resolve(i);const o=e[s++];return Promise.resolve(o()).then((e=>t(e)?Promise.resolve(e):r()))};return r()}class v{constructor(e,t){this._isDisposed=!1,this._token=-1,"function"===typeof e&&"number"===typeof t&&this.setIfNotSet(e,t)}dispose(){this.cancel(),this._isDisposed=!0}cancel(){-1!==this._token&&(clearTimeout(this._token),this._token=-1)}cancelAndSet(e,t){if(this._isDisposed)throw new n.D7("Calling 'cancelAndSet' on a disposed TimeoutTimer");this.cancel(),this._token=setTimeout((()=>{this._token=-1,e()}),t)}setIfNotSet(e,t){if(this._isDisposed)throw new n.D7("Calling 'setIfNotSet' on a disposed TimeoutTimer");-1===this._token&&(this._token=setTimeout((()=>{this._token=-1,e()}),t))}}class C{constructor(){this.disposable=void 0,this.isDisposed=!1}cancel(){this.disposable?.dispose(),this.disposable=void 0}cancelAndSet(e,t,i=globalThis){if(this.isDisposed)throw new n.D7("Calling 'cancelAndSet' on a disposed IntervalTimer");this.cancel();const s=i.setInterval((()=>{e()}),t);this.disposable=(0,o.s)((()=>{i.clearInterval(s),this.disposable=void 0}))}dispose(){this.cancel(),this.isDisposed=!0}}class b{constructor(e,t){this.timeoutToken=-1,this.runner=e,this.timeout=t,this.timeoutHandler=this.onTimeout.bind(this)}dispose(){this.cancel(),this.runner=null}cancel(){this.isScheduled()&&(clearTimeout(this.timeoutToken),this.timeoutToken=-1)}schedule(e=this.timeout){this.cancel(),this.timeoutToken=setTimeout(this.timeoutHandler,e)}get delay(){return this.timeout}set delay(e){this.timeout=e}isScheduled(){return-1!==this.timeoutToken}onTimeout(){this.timeoutToken=-1,this.runner&&this.doRun()}doRun(){this.runner?.()}}let E,S;S="function"!==typeof globalThis.requestIdleCallback||"function"!==typeof globalThis.cancelIdleCallback?(e,t)=>{(0,a._p)((()=>{if(i)return;const e=Date.now()+15,s={didTimeout:!0,timeRemaining:()=>Math.max(0,e-Date.now())};t(Object.freeze(s))}));let i=!1;return{dispose(){i||(i=!0)}}}:(e,t,i)=>{const s=e.requestIdleCallback(t,"number"===typeof i?{timeout:i}:void 0);let n=!1;return{dispose(){n||(n=!0,e.cancelIdleCallback(s))}}},E=e=>S(globalThis,e);class y{constructor(e,t){this._didRun=!1,this._executor=()=>{try{this._value=t()}catch(e){this._error=e}finally{this._didRun=!0}},this._handle=S(e,(()=>this._executor()))}dispose(){this._handle.dispose()}get value(){if(this._didRun||(this._handle.dispose(),this._executor()),this._error)throw this._error;return this._value}get isInitialized(){return this._didRun}}class w extends y{constructor(e){super(globalThis,e)}}class L{get isRejected(){return 1===this.outcome?.outcome}get isSettled(){return!!this.outcome}constructor(){this.p=new Promise(((e,t)=>{this.completeCallback=e,this.errorCallback=t}))}complete(e){return new Promise((t=>{this.completeCallback(e),this.outcome={outcome:0,value:e},t()}))}error(e){return new Promise((t=>{this.errorCallback(e),this.outcome={outcome:1,value:e},t()}))}cancel(){return this.error(new n.AL)}}var R;!function(e){e.settled=async function(e){let t;const i=await Promise.all(e.map((e=>e.then((e=>e),(e=>{t||(t=e)})))));if("undefined"!==typeof t)throw t;return i},e.withAsyncBody=function(e){return new Promise((async(t,i)=>{try{await e(t,i)}catch(s){i(s)}}))}}(R||(R={}));class T{static fromArray(e){return new T((t=>{t.emitMany(e)}))}static fromPromise(e){return new T((async t=>{t.emitMany(await e)}))}static fromPromises(e){return new T((async t=>{await Promise.all(e.map((async e=>t.emitOne(await e))))}))}static merge(e){return new T((async t=>{await Promise.all(e.map((async e=>{for await(const i of e)t.emitOne(i)})))}))}static{this.EMPTY=T.fromArray([])}constructor(e,t){this._state=0,this._results=[],this._error=null,this._onReturn=t,this._onStateChanged=new r.vl,queueMicrotask((async()=>{const t={emitOne:e=>this.emitOne(e),emitMany:e=>this.emitMany(e),reject:e=>this.reject(e)};try{await Promise.resolve(e(t)),this.resolve()}catch(i){this.reject(i)}finally{t.emitOne=void 0,t.emitMany=void 0,t.reject=void 0}}))}[Symbol.asyncIterator](){let e=0;return{next:async()=>{for(;;){if(2===this._state)throw this._error;if(e(this._onReturn?.(),{done:!0,value:void 0})}}static map(e,t){return new T((async i=>{for await(const s of e)i.emitOne(t(s))}))}map(e){return T.map(this,e)}static filter(e,t){return new T((async i=>{for await(const s of e)t(s)&&i.emitOne(s)}))}filter(e){return T.filter(this,e)}static coalesce(e){return T.filter(e,(e=>!!e))}coalesce(){return T.coalesce(this)}static async toPromise(e){const t=[];for await(const i of e)t.push(i);return t}toPromise(){return T.toPromise(this)}emitOne(e){0===this._state&&(this._results.push(e),this._onStateChanged.fire())}emitMany(e){0===this._state&&(this._results=this._results.concat(e),this._onStateChanged.fire())}resolve(){0===this._state&&(this._state=1,this._onStateChanged.fire())}reject(e){0===this._state&&(this._state=2,this._error=e,this._onStateChanged.fire())}}class x extends T{constructor(e,t){super(t),this._source=e}cancel(){this._source.cancel()}}function k(e){const t=new s.Qi,i=e(t.token);return new x(t,(async e=>{const s=t.token.onCancellationRequested((()=>{s.dispose(),t.dispose(),e.reject(new n.AL)}));try{for await(const s of i){if(t.token.isCancellationRequested)return;e.emitOne(s)}s.dispose(),t.dispose()}catch(r){s.dispose(),t.dispose(),e.reject(r)}}))}},81674:(e,t,i)=>{"use strict";i.d(t,{$l:()=>a,Gs:()=>u,MB:()=>o,Sw:()=>h,bb:()=>c,gN:()=>l,pJ:()=>d});var s=i(91090);const n="undefined"!==typeof Buffer;new s.d((()=>new Uint8Array(256)));let r;class o{static wrap(e){return n&&!Buffer.isBuffer(e)&&(e=Buffer.from(e.buffer,e.byteOffset,e.byteLength)),new o(e)}constructor(e){this.buffer=e,this.byteLength=this.buffer.byteLength}toString(){return n?this.buffer.toString():(r||(r=new TextDecoder),r.decode(this.buffer))}}function a(e,t){return(e[t+0]|0)>>>0|e[t+1]<<8>>>0}function l(e,t,i){e[i+0]=255&t,t>>>=8,e[i+1]=255&t}function c(e,t){return e[t]*2**24+65536*e[t+1]+256*e[t+2]+e[t+3]}function h(e,t,i){e[i+3]=t,t>>>=8,e[i+2]=t,t>>>=8,e[i+1]=t,t>>>=8,e[i]=t}function d(e,t){return e[t]}function u(e,t,i){e[i]=t}},81788:(e,t,i)=>{"use strict";function s(e){return e}i.d(t,{VV:()=>r,o5:()=>n});class n{constructor(e,t){this.lastCache=void 0,this.lastArgKey=void 0,"function"===typeof e?(this._fn=e,this._computeKey=s):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);return this.lastArgKey!==t&&(this.lastArgKey=t,this.lastCache=this._fn(e)),this.lastCache}}class r{get cachedValues(){return this._map}constructor(e,t){this._map=new Map,this._map2=new Map,"function"===typeof e?(this._fn=e,this._computeKey=s):(this._fn=t,this._computeKey=e.getCacheKey)}get(e){const t=this._computeKey(e);if(this._map2.has(t))return this._map2.get(t);const i=this._fn(e);return this._map.set(e,i),this._map2.set(t,i),i}}},18447:(e,t,i)=>{"use strict";i.d(t,{Qi:()=>a,XO:()=>r,bs:()=>l});var s=i(41234);const n=Object.freeze((function(e,t){const i=setTimeout(e.bind(t),0);return{dispose(){clearTimeout(i)}}}));var r;!function(e){e.isCancellationToken=function(t){return t===e.None||t===e.Cancelled||(t instanceof o||!(!t||"object"!==typeof t)&&("boolean"===typeof t.isCancellationRequested&&"function"===typeof t.onCancellationRequested))},e.None=Object.freeze({isCancellationRequested:!1,onCancellationRequested:s.Jh.None}),e.Cancelled=Object.freeze({isCancellationRequested:!0,onCancellationRequested:n})}(r||(r={}));class o{constructor(){this._isCancelled=!1,this._emitter=null}cancel(){this._isCancelled||(this._isCancelled=!0,this._emitter&&(this._emitter.fire(void 0),this.dispose()))}get isCancellationRequested(){return this._isCancelled}get onCancellationRequested(){return this._isCancelled?n:(this._emitter||(this._emitter=new s.vl),this._emitter.event)}dispose(){this._emitter&&(this._emitter.dispose(),this._emitter=null)}}class a{constructor(e){this._token=void 0,this._parentListener=void 0,this._parentListener=e&&e.onCancellationRequested(this.cancel,this)}get token(){return this._token||(this._token=new o),this._token}cancel(){this._token?this._token instanceof o&&this._token.cancel():this._token=r.Cancelled}dispose(e=!1){e&&this.cancel(),this._parentListener?.dispose(),this._token?this._token instanceof o&&this._token.dispose():this._token=r.None}}function l(e){const t=new a;return e.add({dispose(){t.cancel()}}),t.token}},10350:(e,t,i)=>{"use strict";i.d(t,{W:()=>n});var s=i(18956);const n={...{add:(0,s.k)("add",6e4),plus:(0,s.k)("plus",6e4),gistNew:(0,s.k)("gist-new",6e4),repoCreate:(0,s.k)("repo-create",6e4),lightbulb:(0,s.k)("lightbulb",60001),lightBulb:(0,s.k)("light-bulb",60001),repo:(0,s.k)("repo",60002),repoDelete:(0,s.k)("repo-delete",60002),gistFork:(0,s.k)("gist-fork",60003),repoForked:(0,s.k)("repo-forked",60003),gitPullRequest:(0,s.k)("git-pull-request",60004),gitPullRequestAbandoned:(0,s.k)("git-pull-request-abandoned",60004),recordKeys:(0,s.k)("record-keys",60005),keyboard:(0,s.k)("keyboard",60005),tag:(0,s.k)("tag",60006),gitPullRequestLabel:(0,s.k)("git-pull-request-label",60006),tagAdd:(0,s.k)("tag-add",60006),tagRemove:(0,s.k)("tag-remove",60006),person:(0,s.k)("person",60007),personFollow:(0,s.k)("person-follow",60007),personOutline:(0,s.k)("person-outline",60007),personFilled:(0,s.k)("person-filled",60007),gitBranch:(0,s.k)("git-branch",60008),gitBranchCreate:(0,s.k)("git-branch-create",60008),gitBranchDelete:(0,s.k)("git-branch-delete",60008),sourceControl:(0,s.k)("source-control",60008),mirror:(0,s.k)("mirror",60009),mirrorPublic:(0,s.k)("mirror-public",60009),star:(0,s.k)("star",60010),starAdd:(0,s.k)("star-add",60010),starDelete:(0,s.k)("star-delete",60010),starEmpty:(0,s.k)("star-empty",60010),comment:(0,s.k)("comment",60011),commentAdd:(0,s.k)("comment-add",60011),alert:(0,s.k)("alert",60012),warning:(0,s.k)("warning",60012),search:(0,s.k)("search",60013),searchSave:(0,s.k)("search-save",60013),logOut:(0,s.k)("log-out",60014),signOut:(0,s.k)("sign-out",60014),logIn:(0,s.k)("log-in",60015),signIn:(0,s.k)("sign-in",60015),eye:(0,s.k)("eye",60016),eyeUnwatch:(0,s.k)("eye-unwatch",60016),eyeWatch:(0,s.k)("eye-watch",60016),circleFilled:(0,s.k)("circle-filled",60017),primitiveDot:(0,s.k)("primitive-dot",60017),closeDirty:(0,s.k)("close-dirty",60017),debugBreakpoint:(0,s.k)("debug-breakpoint",60017),debugBreakpointDisabled:(0,s.k)("debug-breakpoint-disabled",60017),debugHint:(0,s.k)("debug-hint",60017),terminalDecorationSuccess:(0,s.k)("terminal-decoration-success",60017),primitiveSquare:(0,s.k)("primitive-square",60018),edit:(0,s.k)("edit",60019),pencil:(0,s.k)("pencil",60019),info:(0,s.k)("info",60020),issueOpened:(0,s.k)("issue-opened",60020),gistPrivate:(0,s.k)("gist-private",60021),gitForkPrivate:(0,s.k)("git-fork-private",60021),lock:(0,s.k)("lock",60021),mirrorPrivate:(0,s.k)("mirror-private",60021),close:(0,s.k)("close",60022),removeClose:(0,s.k)("remove-close",60022),x:(0,s.k)("x",60022),repoSync:(0,s.k)("repo-sync",60023),sync:(0,s.k)("sync",60023),clone:(0,s.k)("clone",60024),desktopDownload:(0,s.k)("desktop-download",60024),beaker:(0,s.k)("beaker",60025),microscope:(0,s.k)("microscope",60025),vm:(0,s.k)("vm",60026),deviceDesktop:(0,s.k)("device-desktop",60026),file:(0,s.k)("file",60027),fileText:(0,s.k)("file-text",60027),more:(0,s.k)("more",60028),ellipsis:(0,s.k)("ellipsis",60028),kebabHorizontal:(0,s.k)("kebab-horizontal",60028),mailReply:(0,s.k)("mail-reply",60029),reply:(0,s.k)("reply",60029),organization:(0,s.k)("organization",60030),organizationFilled:(0,s.k)("organization-filled",60030),organizationOutline:(0,s.k)("organization-outline",60030),newFile:(0,s.k)("new-file",60031),fileAdd:(0,s.k)("file-add",60031),newFolder:(0,s.k)("new-folder",60032),fileDirectoryCreate:(0,s.k)("file-directory-create",60032),trash:(0,s.k)("trash",60033),trashcan:(0,s.k)("trashcan",60033),history:(0,s.k)("history",60034),clock:(0,s.k)("clock",60034),folder:(0,s.k)("folder",60035),fileDirectory:(0,s.k)("file-directory",60035),symbolFolder:(0,s.k)("symbol-folder",60035),logoGithub:(0,s.k)("logo-github",60036),markGithub:(0,s.k)("mark-github",60036),github:(0,s.k)("github",60036),terminal:(0,s.k)("terminal",60037),console:(0,s.k)("console",60037),repl:(0,s.k)("repl",60037),zap:(0,s.k)("zap",60038),symbolEvent:(0,s.k)("symbol-event",60038),error:(0,s.k)("error",60039),stop:(0,s.k)("stop",60039),variable:(0,s.k)("variable",60040),symbolVariable:(0,s.k)("symbol-variable",60040),array:(0,s.k)("array",60042),symbolArray:(0,s.k)("symbol-array",60042),symbolModule:(0,s.k)("symbol-module",60043),symbolPackage:(0,s.k)("symbol-package",60043),symbolNamespace:(0,s.k)("symbol-namespace",60043),symbolObject:(0,s.k)("symbol-object",60043),symbolMethod:(0,s.k)("symbol-method",60044),symbolFunction:(0,s.k)("symbol-function",60044),symbolConstructor:(0,s.k)("symbol-constructor",60044),symbolBoolean:(0,s.k)("symbol-boolean",60047),symbolNull:(0,s.k)("symbol-null",60047),symbolNumeric:(0,s.k)("symbol-numeric",60048),symbolNumber:(0,s.k)("symbol-number",60048),symbolStructure:(0,s.k)("symbol-structure",60049),symbolStruct:(0,s.k)("symbol-struct",60049),symbolParameter:(0,s.k)("symbol-parameter",60050),symbolTypeParameter:(0,s.k)("symbol-type-parameter",60050),symbolKey:(0,s.k)("symbol-key",60051),symbolText:(0,s.k)("symbol-text",60051),symbolReference:(0,s.k)("symbol-reference",60052),goToFile:(0,s.k)("go-to-file",60052),symbolEnum:(0,s.k)("symbol-enum",60053),symbolValue:(0,s.k)("symbol-value",60053),symbolRuler:(0,s.k)("symbol-ruler",60054),symbolUnit:(0,s.k)("symbol-unit",60054),activateBreakpoints:(0,s.k)("activate-breakpoints",60055),archive:(0,s.k)("archive",60056),arrowBoth:(0,s.k)("arrow-both",60057),arrowDown:(0,s.k)("arrow-down",60058),arrowLeft:(0,s.k)("arrow-left",60059),arrowRight:(0,s.k)("arrow-right",60060),arrowSmallDown:(0,s.k)("arrow-small-down",60061),arrowSmallLeft:(0,s.k)("arrow-small-left",60062),arrowSmallRight:(0,s.k)("arrow-small-right",60063),arrowSmallUp:(0,s.k)("arrow-small-up",60064),arrowUp:(0,s.k)("arrow-up",60065),bell:(0,s.k)("bell",60066),bold:(0,s.k)("bold",60067),book:(0,s.k)("book",60068),bookmark:(0,s.k)("bookmark",60069),debugBreakpointConditionalUnverified:(0,s.k)("debug-breakpoint-conditional-unverified",60070),debugBreakpointConditional:(0,s.k)("debug-breakpoint-conditional",60071),debugBreakpointConditionalDisabled:(0,s.k)("debug-breakpoint-conditional-disabled",60071),debugBreakpointDataUnverified:(0,s.k)("debug-breakpoint-data-unverified",60072),debugBreakpointData:(0,s.k)("debug-breakpoint-data",60073),debugBreakpointDataDisabled:(0,s.k)("debug-breakpoint-data-disabled",60073),debugBreakpointLogUnverified:(0,s.k)("debug-breakpoint-log-unverified",60074),debugBreakpointLog:(0,s.k)("debug-breakpoint-log",60075),debugBreakpointLogDisabled:(0,s.k)("debug-breakpoint-log-disabled",60075),briefcase:(0,s.k)("briefcase",60076),broadcast:(0,s.k)("broadcast",60077),browser:(0,s.k)("browser",60078),bug:(0,s.k)("bug",60079),calendar:(0,s.k)("calendar",60080),caseSensitive:(0,s.k)("case-sensitive",60081),check:(0,s.k)("check",60082),checklist:(0,s.k)("checklist",60083),chevronDown:(0,s.k)("chevron-down",60084),chevronLeft:(0,s.k)("chevron-left",60085),chevronRight:(0,s.k)("chevron-right",60086),chevronUp:(0,s.k)("chevron-up",60087),chromeClose:(0,s.k)("chrome-close",60088),chromeMaximize:(0,s.k)("chrome-maximize",60089),chromeMinimize:(0,s.k)("chrome-minimize",60090),chromeRestore:(0,s.k)("chrome-restore",60091),circleOutline:(0,s.k)("circle-outline",60092),circle:(0,s.k)("circle",60092),debugBreakpointUnverified:(0,s.k)("debug-breakpoint-unverified",60092),terminalDecorationIncomplete:(0,s.k)("terminal-decoration-incomplete",60092),circleSlash:(0,s.k)("circle-slash",60093),circuitBoard:(0,s.k)("circuit-board",60094),clearAll:(0,s.k)("clear-all",60095),clippy:(0,s.k)("clippy",60096),closeAll:(0,s.k)("close-all",60097),cloudDownload:(0,s.k)("cloud-download",60098),cloudUpload:(0,s.k)("cloud-upload",60099),code:(0,s.k)("code",60100),collapseAll:(0,s.k)("collapse-all",60101),colorMode:(0,s.k)("color-mode",60102),commentDiscussion:(0,s.k)("comment-discussion",60103),creditCard:(0,s.k)("credit-card",60105),dash:(0,s.k)("dash",60108),dashboard:(0,s.k)("dashboard",60109),database:(0,s.k)("database",60110),debugContinue:(0,s.k)("debug-continue",60111),debugDisconnect:(0,s.k)("debug-disconnect",60112),debugPause:(0,s.k)("debug-pause",60113),debugRestart:(0,s.k)("debug-restart",60114),debugStart:(0,s.k)("debug-start",60115),debugStepInto:(0,s.k)("debug-step-into",60116),debugStepOut:(0,s.k)("debug-step-out",60117),debugStepOver:(0,s.k)("debug-step-over",60118),debugStop:(0,s.k)("debug-stop",60119),debug:(0,s.k)("debug",60120),deviceCameraVideo:(0,s.k)("device-camera-video",60121),deviceCamera:(0,s.k)("device-camera",60122),deviceMobile:(0,s.k)("device-mobile",60123),diffAdded:(0,s.k)("diff-added",60124),diffIgnored:(0,s.k)("diff-ignored",60125),diffModified:(0,s.k)("diff-modified",60126),diffRemoved:(0,s.k)("diff-removed",60127),diffRenamed:(0,s.k)("diff-renamed",60128),diff:(0,s.k)("diff",60129),diffSidebyside:(0,s.k)("diff-sidebyside",60129),discard:(0,s.k)("discard",60130),editorLayout:(0,s.k)("editor-layout",60131),emptyWindow:(0,s.k)("empty-window",60132),exclude:(0,s.k)("exclude",60133),extensions:(0,s.k)("extensions",60134),eyeClosed:(0,s.k)("eye-closed",60135),fileBinary:(0,s.k)("file-binary",60136),fileCode:(0,s.k)("file-code",60137),fileMedia:(0,s.k)("file-media",60138),filePdf:(0,s.k)("file-pdf",60139),fileSubmodule:(0,s.k)("file-submodule",60140),fileSymlinkDirectory:(0,s.k)("file-symlink-directory",60141),fileSymlinkFile:(0,s.k)("file-symlink-file",60142),fileZip:(0,s.k)("file-zip",60143),files:(0,s.k)("files",60144),filter:(0,s.k)("filter",60145),flame:(0,s.k)("flame",60146),foldDown:(0,s.k)("fold-down",60147),foldUp:(0,s.k)("fold-up",60148),fold:(0,s.k)("fold",60149),folderActive:(0,s.k)("folder-active",60150),folderOpened:(0,s.k)("folder-opened",60151),gear:(0,s.k)("gear",60152),gift:(0,s.k)("gift",60153),gistSecret:(0,s.k)("gist-secret",60154),gist:(0,s.k)("gist",60155),gitCommit:(0,s.k)("git-commit",60156),gitCompare:(0,s.k)("git-compare",60157),compareChanges:(0,s.k)("compare-changes",60157),gitMerge:(0,s.k)("git-merge",60158),githubAction:(0,s.k)("github-action",60159),githubAlt:(0,s.k)("github-alt",60160),globe:(0,s.k)("globe",60161),grabber:(0,s.k)("grabber",60162),graph:(0,s.k)("graph",60163),gripper:(0,s.k)("gripper",60164),heart:(0,s.k)("heart",60165),home:(0,s.k)("home",60166),horizontalRule:(0,s.k)("horizontal-rule",60167),hubot:(0,s.k)("hubot",60168),inbox:(0,s.k)("inbox",60169),issueReopened:(0,s.k)("issue-reopened",60171),issues:(0,s.k)("issues",60172),italic:(0,s.k)("italic",60173),jersey:(0,s.k)("jersey",60174),json:(0,s.k)("json",60175),kebabVertical:(0,s.k)("kebab-vertical",60176),key:(0,s.k)("key",60177),law:(0,s.k)("law",60178),lightbulbAutofix:(0,s.k)("lightbulb-autofix",60179),linkExternal:(0,s.k)("link-external",60180),link:(0,s.k)("link",60181),listOrdered:(0,s.k)("list-ordered",60182),listUnordered:(0,s.k)("list-unordered",60183),liveShare:(0,s.k)("live-share",60184),loading:(0,s.k)("loading",60185),location:(0,s.k)("location",60186),mailRead:(0,s.k)("mail-read",60187),mail:(0,s.k)("mail",60188),markdown:(0,s.k)("markdown",60189),megaphone:(0,s.k)("megaphone",60190),mention:(0,s.k)("mention",60191),milestone:(0,s.k)("milestone",60192),gitPullRequestMilestone:(0,s.k)("git-pull-request-milestone",60192),mortarBoard:(0,s.k)("mortar-board",60193),move:(0,s.k)("move",60194),multipleWindows:(0,s.k)("multiple-windows",60195),mute:(0,s.k)("mute",60196),noNewline:(0,s.k)("no-newline",60197),note:(0,s.k)("note",60198),octoface:(0,s.k)("octoface",60199),openPreview:(0,s.k)("open-preview",60200),package:(0,s.k)("package",60201),paintcan:(0,s.k)("paintcan",60202),pin:(0,s.k)("pin",60203),play:(0,s.k)("play",60204),run:(0,s.k)("run",60204),plug:(0,s.k)("plug",60205),preserveCase:(0,s.k)("preserve-case",60206),preview:(0,s.k)("preview",60207),project:(0,s.k)("project",60208),pulse:(0,s.k)("pulse",60209),question:(0,s.k)("question",60210),quote:(0,s.k)("quote",60211),radioTower:(0,s.k)("radio-tower",60212),reactions:(0,s.k)("reactions",60213),references:(0,s.k)("references",60214),refresh:(0,s.k)("refresh",60215),regex:(0,s.k)("regex",60216),remoteExplorer:(0,s.k)("remote-explorer",60217),remote:(0,s.k)("remote",60218),remove:(0,s.k)("remove",60219),replaceAll:(0,s.k)("replace-all",60220),replace:(0,s.k)("replace",60221),repoClone:(0,s.k)("repo-clone",60222),repoForcePush:(0,s.k)("repo-force-push",60223),repoPull:(0,s.k)("repo-pull",60224),repoPush:(0,s.k)("repo-push",60225),report:(0,s.k)("report",60226),requestChanges:(0,s.k)("request-changes",60227),rocket:(0,s.k)("rocket",60228),rootFolderOpened:(0,s.k)("root-folder-opened",60229),rootFolder:(0,s.k)("root-folder",60230),rss:(0,s.k)("rss",60231),ruby:(0,s.k)("ruby",60232),saveAll:(0,s.k)("save-all",60233),saveAs:(0,s.k)("save-as",60234),save:(0,s.k)("save",60235),screenFull:(0,s.k)("screen-full",60236),screenNormal:(0,s.k)("screen-normal",60237),searchStop:(0,s.k)("search-stop",60238),server:(0,s.k)("server",60240),settingsGear:(0,s.k)("settings-gear",60241),settings:(0,s.k)("settings",60242),shield:(0,s.k)("shield",60243),smiley:(0,s.k)("smiley",60244),sortPrecedence:(0,s.k)("sort-precedence",60245),splitHorizontal:(0,s.k)("split-horizontal",60246),splitVertical:(0,s.k)("split-vertical",60247),squirrel:(0,s.k)("squirrel",60248),starFull:(0,s.k)("star-full",60249),starHalf:(0,s.k)("star-half",60250),symbolClass:(0,s.k)("symbol-class",60251),symbolColor:(0,s.k)("symbol-color",60252),symbolConstant:(0,s.k)("symbol-constant",60253),symbolEnumMember:(0,s.k)("symbol-enum-member",60254),symbolField:(0,s.k)("symbol-field",60255),symbolFile:(0,s.k)("symbol-file",60256),symbolInterface:(0,s.k)("symbol-interface",60257),symbolKeyword:(0,s.k)("symbol-keyword",60258),symbolMisc:(0,s.k)("symbol-misc",60259),symbolOperator:(0,s.k)("symbol-operator",60260),symbolProperty:(0,s.k)("symbol-property",60261),wrench:(0,s.k)("wrench",60261),wrenchSubaction:(0,s.k)("wrench-subaction",60261),symbolSnippet:(0,s.k)("symbol-snippet",60262),tasklist:(0,s.k)("tasklist",60263),telescope:(0,s.k)("telescope",60264),textSize:(0,s.k)("text-size",60265),threeBars:(0,s.k)("three-bars",60266),thumbsdown:(0,s.k)("thumbsdown",60267),thumbsup:(0,s.k)("thumbsup",60268),tools:(0,s.k)("tools",60269),triangleDown:(0,s.k)("triangle-down",60270),triangleLeft:(0,s.k)("triangle-left",60271),triangleRight:(0,s.k)("triangle-right",60272),triangleUp:(0,s.k)("triangle-up",60273),twitter:(0,s.k)("twitter",60274),unfold:(0,s.k)("unfold",60275),unlock:(0,s.k)("unlock",60276),unmute:(0,s.k)("unmute",60277),unverified:(0,s.k)("unverified",60278),verified:(0,s.k)("verified",60279),versions:(0,s.k)("versions",60280),vmActive:(0,s.k)("vm-active",60281),vmOutline:(0,s.k)("vm-outline",60282),vmRunning:(0,s.k)("vm-running",60283),watch:(0,s.k)("watch",60284),whitespace:(0,s.k)("whitespace",60285),wholeWord:(0,s.k)("whole-word",60286),window:(0,s.k)("window",60287),wordWrap:(0,s.k)("word-wrap",60288),zoomIn:(0,s.k)("zoom-in",60289),zoomOut:(0,s.k)("zoom-out",60290),listFilter:(0,s.k)("list-filter",60291),listFlat:(0,s.k)("list-flat",60292),listSelection:(0,s.k)("list-selection",60293),selection:(0,s.k)("selection",60293),listTree:(0,s.k)("list-tree",60294),debugBreakpointFunctionUnverified:(0,s.k)("debug-breakpoint-function-unverified",60295),debugBreakpointFunction:(0,s.k)("debug-breakpoint-function",60296),debugBreakpointFunctionDisabled:(0,s.k)("debug-breakpoint-function-disabled",60296),debugStackframeActive:(0,s.k)("debug-stackframe-active",60297),circleSmallFilled:(0,s.k)("circle-small-filled",60298),debugStackframeDot:(0,s.k)("debug-stackframe-dot",60298),terminalDecorationMark:(0,s.k)("terminal-decoration-mark",60298),debugStackframe:(0,s.k)("debug-stackframe",60299),debugStackframeFocused:(0,s.k)("debug-stackframe-focused",60299),debugBreakpointUnsupported:(0,s.k)("debug-breakpoint-unsupported",60300),symbolString:(0,s.k)("symbol-string",60301),debugReverseContinue:(0,s.k)("debug-reverse-continue",60302),debugStepBack:(0,s.k)("debug-step-back",60303),debugRestartFrame:(0,s.k)("debug-restart-frame",60304),debugAlt:(0,s.k)("debug-alt",60305),callIncoming:(0,s.k)("call-incoming",60306),callOutgoing:(0,s.k)("call-outgoing",60307),menu:(0,s.k)("menu",60308),expandAll:(0,s.k)("expand-all",60309),feedback:(0,s.k)("feedback",60310),gitPullRequestReviewer:(0,s.k)("git-pull-request-reviewer",60310),groupByRefType:(0,s.k)("group-by-ref-type",60311),ungroupByRefType:(0,s.k)("ungroup-by-ref-type",60312),account:(0,s.k)("account",60313),gitPullRequestAssignee:(0,s.k)("git-pull-request-assignee",60313),bellDot:(0,s.k)("bell-dot",60314),debugConsole:(0,s.k)("debug-console",60315),library:(0,s.k)("library",60316),output:(0,s.k)("output",60317),runAll:(0,s.k)("run-all",60318),syncIgnored:(0,s.k)("sync-ignored",60319),pinned:(0,s.k)("pinned",60320),githubInverted:(0,s.k)("github-inverted",60321),serverProcess:(0,s.k)("server-process",60322),serverEnvironment:(0,s.k)("server-environment",60323),pass:(0,s.k)("pass",60324),issueClosed:(0,s.k)("issue-closed",60324),stopCircle:(0,s.k)("stop-circle",60325),playCircle:(0,s.k)("play-circle",60326),record:(0,s.k)("record",60327),debugAltSmall:(0,s.k)("debug-alt-small",60328),vmConnect:(0,s.k)("vm-connect",60329),cloud:(0,s.k)("cloud",60330),merge:(0,s.k)("merge",60331),export:(0,s.k)("export",60332),graphLeft:(0,s.k)("graph-left",60333),magnet:(0,s.k)("magnet",60334),notebook:(0,s.k)("notebook",60335),redo:(0,s.k)("redo",60336),checkAll:(0,s.k)("check-all",60337),pinnedDirty:(0,s.k)("pinned-dirty",60338),passFilled:(0,s.k)("pass-filled",60339),circleLargeFilled:(0,s.k)("circle-large-filled",60340),circleLarge:(0,s.k)("circle-large",60341),circleLargeOutline:(0,s.k)("circle-large-outline",60341),combine:(0,s.k)("combine",60342),gather:(0,s.k)("gather",60342),table:(0,s.k)("table",60343),variableGroup:(0,s.k)("variable-group",60344),typeHierarchy:(0,s.k)("type-hierarchy",60345),typeHierarchySub:(0,s.k)("type-hierarchy-sub",60346),typeHierarchySuper:(0,s.k)("type-hierarchy-super",60347),gitPullRequestCreate:(0,s.k)("git-pull-request-create",60348),runAbove:(0,s.k)("run-above",60349),runBelow:(0,s.k)("run-below",60350),notebookTemplate:(0,s.k)("notebook-template",60351),debugRerun:(0,s.k)("debug-rerun",60352),workspaceTrusted:(0,s.k)("workspace-trusted",60353),workspaceUntrusted:(0,s.k)("workspace-untrusted",60354),workspaceUnknown:(0,s.k)("workspace-unknown",60355),terminalCmd:(0,s.k)("terminal-cmd",60356),terminalDebian:(0,s.k)("terminal-debian",60357),terminalLinux:(0,s.k)("terminal-linux",60358),terminalPowershell:(0,s.k)("terminal-powershell",60359),terminalTmux:(0,s.k)("terminal-tmux",60360),terminalUbuntu:(0,s.k)("terminal-ubuntu",60361),terminalBash:(0,s.k)("terminal-bash",60362),arrowSwap:(0,s.k)("arrow-swap",60363),copy:(0,s.k)("copy",60364),personAdd:(0,s.k)("person-add",60365),filterFilled:(0,s.k)("filter-filled",60366),wand:(0,s.k)("wand",60367),debugLineByLine:(0,s.k)("debug-line-by-line",60368),inspect:(0,s.k)("inspect",60369),layers:(0,s.k)("layers",60370),layersDot:(0,s.k)("layers-dot",60371),layersActive:(0,s.k)("layers-active",60372),compass:(0,s.k)("compass",60373),compassDot:(0,s.k)("compass-dot",60374),compassActive:(0,s.k)("compass-active",60375),azure:(0,s.k)("azure",60376),issueDraft:(0,s.k)("issue-draft",60377),gitPullRequestClosed:(0,s.k)("git-pull-request-closed",60378),gitPullRequestDraft:(0,s.k)("git-pull-request-draft",60379),debugAll:(0,s.k)("debug-all",60380),debugCoverage:(0,s.k)("debug-coverage",60381),runErrors:(0,s.k)("run-errors",60382),folderLibrary:(0,s.k)("folder-library",60383),debugContinueSmall:(0,s.k)("debug-continue-small",60384),beakerStop:(0,s.k)("beaker-stop",60385),graphLine:(0,s.k)("graph-line",60386),graphScatter:(0,s.k)("graph-scatter",60387),pieChart:(0,s.k)("pie-chart",60388),bracket:(0,s.k)("bracket",60175),bracketDot:(0,s.k)("bracket-dot",60389),bracketError:(0,s.k)("bracket-error",60390),lockSmall:(0,s.k)("lock-small",60391),azureDevops:(0,s.k)("azure-devops",60392),verifiedFilled:(0,s.k)("verified-filled",60393),newline:(0,s.k)("newline",60394),layout:(0,s.k)("layout",60395),layoutActivitybarLeft:(0,s.k)("layout-activitybar-left",60396),layoutActivitybarRight:(0,s.k)("layout-activitybar-right",60397),layoutPanelLeft:(0,s.k)("layout-panel-left",60398),layoutPanelCenter:(0,s.k)("layout-panel-center",60399),layoutPanelJustify:(0,s.k)("layout-panel-justify",60400),layoutPanelRight:(0,s.k)("layout-panel-right",60401),layoutPanel:(0,s.k)("layout-panel",60402),layoutSidebarLeft:(0,s.k)("layout-sidebar-left",60403),layoutSidebarRight:(0,s.k)("layout-sidebar-right",60404),layoutStatusbar:(0,s.k)("layout-statusbar",60405),layoutMenubar:(0,s.k)("layout-menubar",60406),layoutCentered:(0,s.k)("layout-centered",60407),target:(0,s.k)("target",60408),indent:(0,s.k)("indent",60409),recordSmall:(0,s.k)("record-small",60410),errorSmall:(0,s.k)("error-small",60411),terminalDecorationError:(0,s.k)("terminal-decoration-error",60411),arrowCircleDown:(0,s.k)("arrow-circle-down",60412),arrowCircleLeft:(0,s.k)("arrow-circle-left",60413),arrowCircleRight:(0,s.k)("arrow-circle-right",60414),arrowCircleUp:(0,s.k)("arrow-circle-up",60415),layoutSidebarRightOff:(0,s.k)("layout-sidebar-right-off",60416),layoutPanelOff:(0,s.k)("layout-panel-off",60417),layoutSidebarLeftOff:(0,s.k)("layout-sidebar-left-off",60418),blank:(0,s.k)("blank",60419),heartFilled:(0,s.k)("heart-filled",60420),map:(0,s.k)("map",60421),mapHorizontal:(0,s.k)("map-horizontal",60421),foldHorizontal:(0,s.k)("fold-horizontal",60421),mapFilled:(0,s.k)("map-filled",60422),mapHorizontalFilled:(0,s.k)("map-horizontal-filled",60422),foldHorizontalFilled:(0,s.k)("fold-horizontal-filled",60422),circleSmall:(0,s.k)("circle-small",60423),bellSlash:(0,s.k)("bell-slash",60424),bellSlashDot:(0,s.k)("bell-slash-dot",60425),commentUnresolved:(0,s.k)("comment-unresolved",60426),gitPullRequestGoToChanges:(0,s.k)("git-pull-request-go-to-changes",60427),gitPullRequestNewChanges:(0,s.k)("git-pull-request-new-changes",60428),searchFuzzy:(0,s.k)("search-fuzzy",60429),commentDraft:(0,s.k)("comment-draft",60430),send:(0,s.k)("send",60431),sparkle:(0,s.k)("sparkle",60432),insert:(0,s.k)("insert",60433),mic:(0,s.k)("mic",60434),thumbsdownFilled:(0,s.k)("thumbsdown-filled",60435),thumbsupFilled:(0,s.k)("thumbsup-filled",60436),coffee:(0,s.k)("coffee",60437),snake:(0,s.k)("snake",60438),game:(0,s.k)("game",60439),vr:(0,s.k)("vr",60440),chip:(0,s.k)("chip",60441),piano:(0,s.k)("piano",60442),music:(0,s.k)("music",60443),micFilled:(0,s.k)("mic-filled",60444),repoFetch:(0,s.k)("repo-fetch",60445),copilot:(0,s.k)("copilot",60446),lightbulbSparkle:(0,s.k)("lightbulb-sparkle",60447),robot:(0,s.k)("robot",60448),sparkleFilled:(0,s.k)("sparkle-filled",60449),diffSingle:(0,s.k)("diff-single",60450),diffMultiple:(0,s.k)("diff-multiple",60451),surroundWith:(0,s.k)("surround-with",60452),share:(0,s.k)("share",60453),gitStash:(0,s.k)("git-stash",60454),gitStashApply:(0,s.k)("git-stash-apply",60455),gitStashPop:(0,s.k)("git-stash-pop",60456),vscode:(0,s.k)("vscode",60457),vscodeInsiders:(0,s.k)("vscode-insiders",60458),codeOss:(0,s.k)("code-oss",60459),runCoverage:(0,s.k)("run-coverage",60460),runAllCoverage:(0,s.k)("run-all-coverage",60461),coverage:(0,s.k)("coverage",60462),githubProject:(0,s.k)("github-project",60463),mapVertical:(0,s.k)("map-vertical",60464),foldVertical:(0,s.k)("fold-vertical",60464),mapVerticalFilled:(0,s.k)("map-vertical-filled",60465),foldVerticalFilled:(0,s.k)("fold-vertical-filled",60465),goToSearch:(0,s.k)("go-to-search",60466),percentage:(0,s.k)("percentage",60467),sortPercentage:(0,s.k)("sort-percentage",60467),attach:(0,s.k)("attach",60468)},...{dialogError:(0,s.k)("dialog-error","error"),dialogWarning:(0,s.k)("dialog-warning","warning"),dialogInfo:(0,s.k)("dialog-info","info"),dialogClose:(0,s.k)("dialog-close","close"),treeItemExpanded:(0,s.k)("tree-item-expanded","chevron-down"),treeFilterOnTypeOn:(0,s.k)("tree-filter-on-type-on","list-filter"),treeFilterOnTypeOff:(0,s.k)("tree-filter-on-type-off","list-selection"),treeFilterClear:(0,s.k)("tree-filter-clear","close"),treeItemLoading:(0,s.k)("tree-item-loading","loading"),menuSelection:(0,s.k)("menu-selection","check"),menuSubmenu:(0,s.k)("menu-submenu","chevron-right"),menuBarMore:(0,s.k)("menubar-more","more"),scrollbarButtonLeft:(0,s.k)("scrollbar-button-left","triangle-left"),scrollbarButtonRight:(0,s.k)("scrollbar-button-right","triangle-right"),scrollbarButtonUp:(0,s.k)("scrollbar-button-up","triangle-up"),scrollbarButtonDown:(0,s.k)("scrollbar-button-down","triangle-down"),toolBarMore:(0,s.k)("toolbar-more","more"),quickInputBack:(0,s.k)("quick-input-back","arrow-left"),dropDownButton:(0,s.k)("drop-down-button",60084),symbolCustomColor:(0,s.k)("symbol-customcolor",60252),exportIcon:(0,s.k)("export",60332),workspaceUnspecified:(0,s.k)("workspace-unspecified",60355),newLine:(0,s.k)("newline",60394),thumbsDownFilled:(0,s.k)("thumbsdown-filled",60435),thumbsUpFilled:(0,s.k)("thumbsup-filled",60436),gitFetch:(0,s.k)("git-fetch",60445),lightbulbSparkleAutofix:(0,s.k)("lightbulb-sparkle-autofix",60447),debugBreakpointPending:(0,s.k)("debug-breakpoint-pending",60377)}}},18956:(e,t,i)=>{"use strict";i.d(t,{J:()=>o,k:()=>r});var s=i(631);const n=Object.create(null);function r(e,t){if((0,s.Kg)(t)){const i=n[t];if(void 0===i)throw new Error(`${e} references an unknown codicon: ${t}`);t=i}return n[e]=t,{id:e}}function o(){return n}},48495:(e,t,i)=>{"use strict";function s(e,t){const i=[],s=[];for(const n of e)t.has(n)||i.push(n);for(const n of t)e.has(n)||s.push(n);return{removed:i,added:s}}function n(e,t){const i=new Set;for(const s of t)e.has(s)&&i.add(s);return i}i.d(t,{E:()=>n,Z:()=>s})},47661:(e,t,i)=>{"use strict";function s(e,t){const i=Math.pow(10,t);return Math.round(e*i)/i}i.d(t,{$J:()=>o,Q1:()=>a,bU:()=>n,hB:()=>r});class n{constructor(e,t,i,n=1){this._rgbaBrand=void 0,this.r=0|Math.min(255,Math.max(0,e)),this.g=0|Math.min(255,Math.max(0,t)),this.b=0|Math.min(255,Math.max(0,i)),this.a=s(Math.max(Math.min(1,n),0),3)}static equals(e,t){return e.r===t.r&&e.g===t.g&&e.b===t.b&&e.a===t.a}}class r{constructor(e,t,i,n){this._hslaBrand=void 0,this.h=0|Math.max(Math.min(360,e),0),this.s=s(Math.max(Math.min(1,t),0),3),this.l=s(Math.max(Math.min(1,i),0),3),this.a=s(Math.max(Math.min(1,n),0),3)}static equals(e,t){return e.h===t.h&&e.s===t.s&&e.l===t.l&&e.a===t.a}static fromRGBA(e){const t=e.r/255,i=e.g/255,s=e.b/255,n=e.a,o=Math.max(t,i,s),a=Math.min(t,i,s);let l=0,c=0;const h=(a+o)/2,d=o-a;if(d>0){switch(c=Math.min(h<=.5?d/(2*h):d/(2-2*h),1),o){case t:l=(i-s)/d+(i1&&(i-=1),i<1/6?e+6*(t-e)*i:i<.5?t:i<2/3?e+(t-e)*(2/3-i)*6:e}static toRGBA(e){const t=e.h/360,{s:i,l:s,a:o}=e;let a,l,c;if(0===i)a=l=c=s;else{const e=s<.5?s*(1+i):s+i-s*i,n=2*s-e;a=r._hue2rgb(n,e,t+1/3),l=r._hue2rgb(n,e,t),c=r._hue2rgb(n,e,t-1/3)}return new n(Math.round(255*a),Math.round(255*l),Math.round(255*c),o)}}class o{constructor(e,t,i,n){this._hsvaBrand=void 0,this.h=0|Math.max(Math.min(360,e),0),this.s=s(Math.max(Math.min(1,t),0),3),this.v=s(Math.max(Math.min(1,i),0),3),this.a=s(Math.max(Math.min(1,n),0),3)}static equals(e,t){return e.h===t.h&&e.s===t.s&&e.v===t.v&&e.a===t.a}static fromRGBA(e){const t=e.r/255,i=e.g/255,s=e.b/255,n=Math.max(t,i,s),r=n-Math.min(t,i,s),a=0===n?0:r/n;let l;return l=0===r?0:n===t?((i-s)/r%6+6)%6:n===i?(s-t)/r+2:(t-i)/r+4,new o(Math.round(60*l),a,n,e.a)}static toRGBA(e){const{h:t,s:i,v:s,a:r}=e,o=s*i,a=o*(1-Math.abs(t/60%2-1)),l=s-o;let[c,h,d]=[0,0,0];return t<60?(c=o,h=a):t<120?(c=a,h=o):t<180?(h=o,d=a):t<240?(h=a,d=o):t<300?(c=a,d=o):t<=360&&(c=o,d=a),c=Math.round(255*(c+l)),h=Math.round(255*(h+l)),d=Math.round(255*(d+l)),new n(c,h,d,r)}}class a{static fromHex(e){return a.Format.CSS.parseHex(e)||a.red}static equals(e,t){return!e&&!t||!(!e||!t)&&e.equals(t)}get hsla(){return this._hsla?this._hsla:r.fromRGBA(this.rgba)}get hsva(){return this._hsva?this._hsva:o.fromRGBA(this.rgba)}constructor(e){if(!e)throw new Error("Color needs a value");if(e instanceof n)this.rgba=e;else if(e instanceof r)this._hsla=e,this.rgba=r.toRGBA(e);else{if(!(e instanceof o))throw new Error("Invalid color ctor argument");this._hsva=e,this.rgba=o.toRGBA(e)}}equals(e){return!!e&&n.equals(this.rgba,e.rgba)&&r.equals(this.hsla,e.hsla)&&o.equals(this.hsva,e.hsva)}getRelativeLuminance(){return s(.2126*a._relativeLuminanceForComponent(this.rgba.r)+.7152*a._relativeLuminanceForComponent(this.rgba.g)+.0722*a._relativeLuminanceForComponent(this.rgba.b),4)}static _relativeLuminanceForComponent(e){const t=e/255;return t<=.03928?t/12.92:Math.pow((t+.055)/1.055,2.4)}isLighter(){return(299*this.rgba.r+587*this.rgba.g+114*this.rgba.b)/1e3>=128}isLighterThan(e){return this.getRelativeLuminance()>e.getRelativeLuminance()}isDarkerThan(e){return this.getRelativeLuminance(){"use strict";i.d(t,{VX:()=>a,Vq:()=>l,Y:()=>h,gf:()=>o,jt:()=>u});var s=i(25890),n=i(42522),r=i(58255);function o(e){return{asString:async()=>e,asFile:()=>{},value:"string"===typeof e?e:void 0}}function a(e,t,i){const s={id:(0,r.b)(),name:e,uri:t,data:i};return{asString:async()=>"",asFile:()=>s,value:void 0}}class l{constructor(){this._entries=new Map}get size(){let e=0;for(const t of this._entries)e++;return e}has(e){return this._entries.has(this.toKey(e))}matches(e){const t=[...this._entries.keys()];return n.f.some(this,(([e,t])=>t.asFile()))&&t.push("files"),d(c(e),t)}get(e){return this._entries.get(this.toKey(e))?.[0]}append(e,t){const i=this._entries.get(e);i?i.push(t):this._entries.set(this.toKey(e),[t])}replace(e,t){this._entries.set(this.toKey(e),[t])}delete(e){this._entries.delete(this.toKey(e))}*[Symbol.iterator](){for(const[e,t]of this._entries)for(const i of t)yield[e,i]}toKey(e){return c(e)}}function c(e){return e.toLowerCase()}function h(e,t){return d(c(e),t.map(c))}function d(e,t){if("*/*"===e)return t.length>0;if(t.includes(e))return!0;const i=e.match(/^([a-z]+)\/([a-z]+|\*)$/i);if(!i)return!1;const[s,n,r]=i;return"*"===r&&t.some((e=>e.startsWith(n+"/")))}const u=Object.freeze({create:e=>(0,s.dM)(e.map((e=>e.toString()))).join("\r\n"),split:e=>e.split("\r\n"),parse:e=>u.split(e).filter((e=>!e.startsWith("#")))})},58694:(e,t,i)=>{"use strict";function s(e,t,i){let s=null,n=null;if("function"===typeof i.value?(s="value",n=i.value,0!==n.length&&console.warn("Memoize should only be used in functions with zero parameters")):"function"===typeof i.get&&(s="get",n=i.get),!n)throw new Error("not supported");const r=`$memoize$${t}`;i[s]=function(...e){return this.hasOwnProperty(r)||Object.defineProperty(this,r,{configurable:!1,enumerable:!1,writable:!1,value:n.apply(this,e)}),this[r]}}i.d(t,{B:()=>s})},83993:(e,t,i)=>{"use strict";i.d(t,{uP:()=>h,F1:()=>o});class s{constructor(e,t,i,s){this.originalStart=e,this.originalLength=t,this.modifiedStart=i,this.modifiedLength=s}getOriginalEnd(){return this.originalStart+this.originalLength}getModifiedEnd(){return this.modifiedStart+this.modifiedLength}}var n=i(85600);class r{constructor(e){this.source=e}getElements(){const e=this.source,t=new Int32Array(e.length);for(let i=0,s=e.length;i0||this.m_modifiedCount>0)&&this.m_changes.push(new s(this.m_originalStart,this.m_originalCount,this.m_modifiedStart,this.m_modifiedCount)),this.m_originalCount=0,this.m_modifiedCount=0,this.m_originalStart=1073741824,this.m_modifiedStart=1073741824}AddOriginalElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_originalCount++}AddModifiedElement(e,t){this.m_originalStart=Math.min(this.m_originalStart,e),this.m_modifiedStart=Math.min(this.m_modifiedStart,t),this.m_modifiedCount++}getChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes}getReverseChanges(){return(this.m_originalCount>0||this.m_modifiedCount>0)&&this.MarkNextChange(),this.m_changes.reverse(),this.m_changes}}class h{constructor(e,t,i=null){this.ContinueProcessingPredicate=i,this._originalSequence=e,this._modifiedSequence=t;const[s,n,r]=h._getElements(e),[o,a,l]=h._getElements(t);this._hasStrings=r&&l,this._originalStringElements=s,this._originalElementsOrHash=n,this._modifiedStringElements=o,this._modifiedElementsOrHash=a,this.m_forwardHistory=[],this.m_reverseHistory=[]}static _isStringArray(e){return e.length>0&&"string"===typeof e[0]}static _getElements(e){const t=e.getElements();if(h._isStringArray(t)){const e=new Int32Array(t.length);for(let i=0,s=t.length;i=e&&n>=i&&this.ElementsAreEqual(t,n);)t--,n--;if(e>t||i>n){let r;return i<=n?(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),r=[new s(e,0,i,n-i+1)]):e<=t?(a.Assert(i===n+1,"modifiedStart should only be one more than modifiedEnd"),r=[new s(e,t-e+1,i,0)]):(a.Assert(e===t+1,"originalStart should only be one more than originalEnd"),a.Assert(i===n+1,"modifiedStart should only be one more than modifiedEnd"),r=[]),r}const o=[0],l=[0],c=this.ComputeRecursionPoint(e,t,i,n,o,l,r),h=o[0],d=l[0];if(null!==c)return c;if(!r[0]){const o=this.ComputeDiffRecursive(e,h,i,d,r);let a=[];return a=r[0]?[new s(h+1,t-(h+1)+1,d+1,n-(d+1)+1)]:this.ComputeDiffRecursive(h+1,t,d+1,n,r),this.ConcatenateChanges(o,a)}return[new s(e,t-e+1,i,n-i+1)]}WALKTRACE(e,t,i,n,r,o,a,l,h,d,u,g,p,m,f,_,v,C){let b=null,E=null,S=new c,y=t,w=i,L=p[0]-_[0]-n,R=-1073741824,T=this.m_forwardHistory.length-1;do{const t=L+e;t===y||t=0&&(e=(h=this.m_forwardHistory[T])[0],y=1,w=h.length-1)}while(--T>=-1);if(b=S.getReverseChanges(),C[0]){let e=p[0]+1,t=_[0]+1;if(null!==b&&b.length>0){const i=b[b.length-1];e=Math.max(e,i.getOriginalEnd()),t=Math.max(t,i.getModifiedEnd())}E=[new s(e,g-e+1,t,f-t+1)]}else{S=new c,y=o,w=a,L=p[0]-_[0]-l,R=1073741824,T=v?this.m_reverseHistory.length-1:this.m_reverseHistory.length-2;do{const e=L+r;e===y||e=d[e+1]?(m=(u=d[e+1]-1)-L-l,u>R&&S.MarkNextChange(),R=u+1,S.AddOriginalElement(u+1,m+1),L=e+1-r):(m=(u=d[e-1])-L-l,u>R&&S.MarkNextChange(),R=u,S.AddModifiedElement(u+1,m+1),L=e-1-r),T>=0&&(r=(d=this.m_reverseHistory[T])[0],y=1,w=d.length-1)}while(--T>=-1);E=S.getChanges()}return this.ConcatenateChanges(b,E)}ComputeRecursionPoint(e,t,i,n,r,o,a){let c=0,h=0,d=0,u=0,g=0,p=0;e--,i--,r[0]=0,o[0]=0,this.m_forwardHistory=[],this.m_reverseHistory=[];const m=t-e+(n-i),f=m+1,_=new Int32Array(f),v=new Int32Array(f),C=n-i,b=t-e,E=e-i,S=t-n,y=(b-C)%2===0;_[C]=e,v[b]=t,a[0]=!1;for(let w=1;w<=m/2+1;w++){let m=0,L=0;d=this.ClipDiagonalBound(C-w,w,C,f),u=this.ClipDiagonalBound(C+w,w,C,f);for(let e=d;e<=u;e+=2){c=e===d||em+L&&(m=c,L=h),!y&&Math.abs(e-b)<=w-1&&c>=v[e])return r[0]=c,o[0]=h,i<=v[e]&&w<=1448?this.WALKTRACE(C,d,u,E,b,g,p,S,_,v,c,t,r,h,n,o,y,a):null}const R=(m-e+(L-i)-w)/2;if(null!==this.ContinueProcessingPredicate&&!this.ContinueProcessingPredicate(m,R))return a[0]=!0,r[0]=m,o[0]=L,R>0&&w<=1448?this.WALKTRACE(C,d,u,E,b,g,p,S,_,v,c,t,r,h,n,o,y,a):(e++,i++,[new s(e,t-e+1,i,n-i+1)]);g=this.ClipDiagonalBound(b-w,w,b,f),p=this.ClipDiagonalBound(b+w,w,b,f);for(let s=g;s<=p;s+=2){c=s===g||s=v[s+1]?v[s+1]-1:v[s-1],h=c-(s-b)-S;const l=c;for(;c>e&&h>i&&this.ElementsAreEqual(c,h);)c--,h--;if(v[s]=c,y&&Math.abs(s-C)<=w&&c<=_[s])return r[0]=c,o[0]=h,l>=_[s]&&w<=1448?this.WALKTRACE(C,d,u,E,b,g,p,S,_,v,c,t,r,h,n,o,y,a):null}if(w<=1447){let e=new Int32Array(u-d+2);e[0]=C-d+1,l.Copy2(_,d,e,1,u-d+1),this.m_forwardHistory.push(e),e=new Int32Array(p-g+2),e[0]=b-g+1,l.Copy2(v,g,e,1,p-g+1),this.m_reverseHistory.push(e)}}return this.WALKTRACE(C,d,u,E,b,g,p,S,_,v,c,t,r,h,n,o,y,a)}PrettifyChanges(e){for(let t=0;t0,o=i.modifiedLength>0;for(;i.originalStart+i.originalLength=0;t--){const i=e[t];let s=0,n=0;if(t>0){const i=e[t-1];s=i.originalStart+i.originalLength,n=i.modifiedStart+i.modifiedLength}const r=i.originalLength>0,o=i.modifiedLength>0;let a=0,l=this._boundaryScore(i.originalStart,i.originalLength,i.modifiedStart,i.modifiedLength);for(let e=1;;e++){const t=i.originalStart-e,c=i.modifiedStart-e;if(tl&&(l=h,a=e)}i.originalStart-=a,i.modifiedStart-=a;const c=[null];t>0&&this.ChangesOverlap(e[t-1],e[t],c)&&(e[t-1]=c[0],e.splice(t,1),t++)}if(this._hasStrings)for(let t=1,i=e.length;t0&&t>a&&(a=t,l=h,c=e)}return a>0?[l,c]:null}_contiguousSequenceScore(e,t,i){let s=0;for(let n=0;n=this._originalElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._originalStringElements[e])}_OriginalRegionIsBoundary(e,t){if(this._OriginalIsBoundary(e)||this._OriginalIsBoundary(e-1))return!0;if(t>0){const i=e+t;if(this._OriginalIsBoundary(i-1)||this._OriginalIsBoundary(i))return!0}return!1}_ModifiedIsBoundary(e){return e<=0||e>=this._modifiedElementsOrHash.length-1||this._hasStrings&&/^\s*$/.test(this._modifiedStringElements[e])}_ModifiedRegionIsBoundary(e,t){if(this._ModifiedIsBoundary(e)||this._ModifiedIsBoundary(e-1))return!0;if(t>0){const i=e+t;if(this._ModifiedIsBoundary(i-1)||this._ModifiedIsBoundary(i))return!0}return!1}_boundaryScore(e,t,i,s){return(this._OriginalRegionIsBoundary(e,t)?1:0)+(this._ModifiedRegionIsBoundary(i,s)?1:0)}ConcatenateChanges(e,t){const i=[];if(0===e.length||0===t.length)return t.length>0?t:e;if(this.ChangesOverlap(e[e.length-1],t[0],i)){const s=new Array(e.length+t.length-1);return l.Copy(e,0,s,0,e.length-1),s[e.length-1]=i[0],l.Copy(t,1,s,e.length,t.length-1),s}{const i=new Array(e.length+t.length);return l.Copy(e,0,i,0,e.length),l.Copy(t,0,i,e.length,t.length),i}}ChangesOverlap(e,t,i){if(a.Assert(e.originalStart<=t.originalStart,"Left change is not less than or equal to right change"),a.Assert(e.modifiedStart<=t.modifiedStart,"Left change is not less than or equal to right change"),e.originalStart+e.originalLength>=t.originalStart||e.modifiedStart+e.modifiedLength>=t.modifiedStart){const n=e.originalStart;let r=e.originalLength;const o=e.modifiedStart;let a=e.modifiedLength;return e.originalStart+e.originalLength>=t.originalStart&&(r=t.originalStart+t.originalLength-e.originalStart),e.modifiedStart+e.modifiedLength>=t.modifiedStart&&(a=t.modifiedStart+t.modifiedLength-e.modifiedStart),i[0]=new s(n,r,o,a),!0}return i[0]=null,!1}ClipDiagonalBound(e,t,i,s){if(e>=0&&e{"use strict";i.d(t,{KC:()=>a,S3:()=>r,dB:()=>l,nx:()=>n,r:()=>o});var s=i(25890);const n=(e,t)=>e===t;function r(e=n){return(t,i)=>s.aI(t,i,e)}function o(){return(e,t)=>e.equals(t)}function a(e,t,i){if(void 0!==i){return void 0===e||null===e||void 0===t||null===t?t===e:i(e,t)}{const t=e;return(e,i)=>void 0===e||null===e||void 0===i||null===i?i===e:t(e,i)}}function l(e,t){if(e===t)return!0;if(Array.isArray(e)&&Array.isArray(t)){if(e.length!==t.length)return!1;for(let i=0;i{"use strict";i.d(t,{r:()=>c});var s=i(25890),n=i(631),r=i(78209);function o(e,t){return t&&(e.stack||e.stacktrace)?r.kg("stackTrace.format","{0}: {1}",l(e),a(e.stack)||a(e.stacktrace)):l(e)}function a(e){return Array.isArray(e)?e.join("\n"):e}function l(e){return"ERR_UNC_HOST_NOT_ALLOWED"===e.code?`${e.message}. Please update the 'security.allowedUNCHosts' setting if you want to allow this host.`:"string"===typeof e.code&&"number"===typeof e.errno&&"string"===typeof e.syscall?r.kg("nodeExceptionMessage","A system error occurred ({0})",e.message):e.message||r.kg("error.defaultMessage","An unknown error occurred. Please consult the log for more details.")}function c(e=null,t=!1){if(!e)return r.kg("error.defaultMessage","An unknown error occurred. Please consult the log for more details.");if(Array.isArray(e)){const i=s.Yc(e),n=c(i[0],t);return i.length>1?r.kg("error.moreErrors","{0} ({1} errors in total)",n,i.length):n}if(n.Kg(e))return e;if(e.detail){const i=e.detail;if(i.error)return o(i.error,t);if(i.exception)return o(i.exception,t)}return e.stack?o(e,t):e.message?e.message:r.kg("error.defaultMessage","An unknown error occurred. Please consult the log for more details.")}},64383:(e,t,i)=>{"use strict";i.d(t,{AL:()=>c,D7:()=>m,EM:()=>g,MB:()=>l,M_:()=>r,Qg:()=>d,aD:()=>h,cU:()=>o,dz:()=>n,iH:()=>u});const s=new class{constructor(){this.listeners=[],this.unexpectedErrorHandler=function(e){setTimeout((()=>{if(e.stack){if(p.isErrorNoTelemetry(e))throw new p(e.message+"\n\n"+e.stack);throw new Error(e.message+"\n\n"+e.stack)}throw e}),0)}}emit(e){this.listeners.forEach((t=>{t(e)}))}onUnexpectedError(e){this.unexpectedErrorHandler(e),this.emit(e)}onUnexpectedExternalError(e){this.unexpectedErrorHandler(e)}};function n(e){l(e)||s.onUnexpectedError(e)}function r(e){l(e)||s.onUnexpectedExternalError(e)}function o(e){if(e instanceof Error){const{name:t,message:i}=e;return{$isError:!0,name:t,message:i,stack:e.stacktrace||e.stack,noTelemetry:p.isErrorNoTelemetry(e)}}return e}const a="Canceled";function l(e){return e instanceof c||e instanceof Error&&e.name===a&&e.message===a}class c extends Error{constructor(){super(a),this.name=this.message}}function h(){const e=new Error(a);return e.name=e.message,e}function d(e){return e?new Error(`Illegal argument: ${e}`):new Error("Illegal argument")}function u(e){return e?new Error(`Illegal state: ${e}`):new Error("Illegal state")}class g extends Error{constructor(e){super("NotSupported"),e&&(this.message=e)}}class p extends Error{constructor(e){super(e),this.name="CodeExpectedError"}static fromError(e){if(e instanceof p)return e;const t=new p;return t.message=e.message,t.stack=e.stack,t}static isErrorNoTelemetry(e){return"CodeExpectedError"===e.name}}class m extends Error{constructor(e){super(e||"An unexpected bug occurred."),Object.setPrototypeOf(this,m.prototype)}}},41234:(e,t,i)=>{"use strict";i.d(t,{Jh:()=>l,QT:()=>E,Qy:()=>_,Wj:()=>w,_B:()=>S,at:()=>y,fV:()=>C,uI:()=>b,vl:()=>f});var s=i(64383),n=i(6921),r=i(5662),o=i(58925),a=i(78381);var l;!function(e){function t(e){false}function i(e){return(t,i=null,s)=>{let n,r=!1;return n=e((e=>{if(!r)return n?n.dispose():r=!0,t.call(i,e)}),null,s),r&&n.dispose(),n}}function s(e,t,i){return o(((i,s=null,n)=>e((e=>i.call(s,t(e))),null,n)),i)}function n(e,t,i){return o(((i,s=null,n)=>e((e=>t(e)&&i.call(s,e)),null,n)),i)}function o(e,i){let s;const n={onWillAddFirstListener(){s=e(r.fire,r)},onDidRemoveLastListener(){s?.dispose()}};i||t();const r=new f(n);return i?.add(r),r.event}function a(e,i,s=100,n=!1,r=!1,o,a){let l,c,h,d,u=0;const g={leakWarningThreshold:o,onWillAddFirstListener(){l=e((e=>{u++,c=i(c,e),n&&!h&&(p.fire(c),c=void 0),d=()=>{const e=c;c=void 0,h=void 0,(!n||u>1)&&p.fire(e),u=0},"number"===typeof s?(clearTimeout(h),h=setTimeout(d,s)):void 0===h&&(h=0,queueMicrotask(d))}))},onWillRemoveListener(){r&&u>0&&d?.()},onDidRemoveLastListener(){d=void 0,l.dispose()}};a||t();const p=new f(g);return a?.add(p),p.event}e.None=()=>r.jG.None,e.defer=function(e,t){return a(e,(()=>{}),0,void 0,!0,void 0,t)},e.once=i,e.onceIf=function(t,i){return e.once(e.filter(t,i))},e.map=s,e.forEach=function(e,t,i){return o(((i,s=null,n)=>e((e=>{t(e),i.call(s,e)}),null,n)),i)},e.filter=n,e.signal=function(e){return e},e.any=function(...e){return(t,i=null,s)=>function(e,t){t instanceof Array?t.push(e):t&&t.add(e);return e}((0,r.qE)(...e.map((e=>e((e=>t.call(i,e)))))),s)},e.reduce=function(e,t,i,n){let r=i;return s(e,(e=>(r=t(r,e),r)),n)},e.debounce=a,e.accumulate=function(t,i=0,s){return e.debounce(t,((e,t)=>e?(e.push(t),e):[t]),i,void 0,!0,void 0,s)},e.latch=function(e,t=(e,t)=>e===t,i){let s,r=!0;return n(e,(e=>{const i=r||!t(e,s);return r=!1,s=e,i}),i)},e.split=function(t,i,s){return[e.filter(t,i,s),e.filter(t,(e=>!i(e)),s)]},e.buffer=function(e,t=!1,i=[],s){let n=i.slice(),r=e((e=>{n?n.push(e):a.fire(e)}));s&&s.add(r);const o=()=>{n?.forEach((e=>a.fire(e))),n=null},a=new f({onWillAddFirstListener(){r||(r=e((e=>a.fire(e))),s&&s.add(r))},onDidAddFirstListener(){n&&(t?setTimeout(o):o())},onDidRemoveLastListener(){r&&r.dispose(),r=null}});return s&&s.add(a),a.event},e.chain=function(e,t){return(i,s,n)=>{const r=t(new c);return e((function(e){const t=r.evaluate(e);t!==l&&i.call(s,t)}),void 0,n)}};const l=Symbol("HaltChainable");class c{constructor(){this.steps=[]}map(e){return this.steps.push(e),this}forEach(e){return this.steps.push((t=>(e(t),t))),this}filter(e){return this.steps.push((t=>e(t)?t:l)),this}reduce(e,t){let i=t;return this.steps.push((t=>(i=e(i,t),i))),this}latch(e=(e,t)=>e===t){let t,i=!0;return this.steps.push((s=>{const n=i||!e(s,t);return i=!1,t=s,n?s:l})),this}evaluate(e){for(const t of this.steps)if((e=t(e))===l)break;return e}}e.fromNodeEventEmitter=function(e,t,i=e=>e){const s=(...e)=>n.fire(i(...e)),n=new f({onWillAddFirstListener:()=>e.on(t,s),onDidRemoveLastListener:()=>e.removeListener(t,s)});return n.event},e.fromDOMEventEmitter=function(e,t,i=e=>e){const s=(...e)=>n.fire(i(...e)),n=new f({onWillAddFirstListener:()=>e.addEventListener(t,s),onDidRemoveLastListener:()=>e.removeEventListener(t,s)});return n.event},e.toPromise=function(e){return new Promise((t=>i(e)(t)))},e.fromPromise=function(e){const t=new f;return e.then((e=>{t.fire(e)}),(()=>{t.fire(void 0)})).finally((()=>{t.dispose()})),t.event},e.forward=function(e,t){return e((e=>t.fire(e)))},e.runAndSubscribe=function(e,t,i){return t(i),e((e=>t(e)))};class h{constructor(e,i){this._observable=e,this._counter=0,this._hasChanged=!1;const s={onWillAddFirstListener:()=>{e.addObserver(this),this._observable.reportChanges()},onDidRemoveLastListener:()=>{e.removeObserver(this)}};i||t(),this.emitter=new f(s),i&&i.add(this.emitter)}beginUpdate(e){this._counter++}handlePossibleChange(e){}handleChange(e,t){this._hasChanged=!0}endUpdate(e){this._counter--,0===this._counter&&(this._observable.reportChanges(),this._hasChanged&&(this._hasChanged=!1,this.emitter.fire(this._observable.get())))}}e.fromObservable=function(e,t){return new h(e,t).emitter.event},e.fromObservableLight=function(e){return(t,i,s)=>{let n=0,o=!1;const a={beginUpdate(){n++},endUpdate(){n--,0===n&&(e.reportChanges(),o&&(o=!1,t.call(i)))},handlePossibleChange(){},handleChange(){o=!0}};e.addObserver(a),e.reportChanges();const l={dispose(){e.removeObserver(a)}};return s instanceof r.Cm?s.add(l):Array.isArray(s)&&s.push(l),l}}}(l||(l={}));class c{static{this.all=new Set}static{this._idPool=0}constructor(e){this.listenerCount=0,this.invocationCount=0,this.elapsedOverall=0,this.durations=[],this.name=`${e}_${c._idPool++}`,c.all.add(this)}start(e){this._stopWatch=new a.W,this.listenerCount=e}stop(){if(this._stopWatch){const e=this._stopWatch.elapsed();this.durations.push(e),this.elapsedOverall+=e,this.invocationCount+=1,this._stopWatch=void 0}}}class h{static{this._idPool=1}constructor(e,t,i=(h._idPool++).toString(16).padStart(3,"0")){this._errorHandler=e,this.threshold=t,this.name=i,this._warnCountdown=0}dispose(){this._stacks?.clear()}check(e,t){const i=this.threshold;if(i<=0||t{const t=this._stacks.get(e.value)||0;this._stacks.set(e.value,t-1)}}getMostFrequentStack(){if(!this._stacks)return;let e,t=0;for(const[i,s]of this._stacks)(!e||t{if(this._leakageMon&&this._size>this._leakageMon.threshold**2){const e=`[${this._leakageMon.name}] REFUSES to accept new listeners because it exceeded its threshold by far (${this._size} vs ${this._leakageMon.threshold})`;console.warn(e);const t=this._leakageMon.getMostFrequentStack()??["UNKNOWN stack",-1],i=new g(`${e}. HINT: Stack shows most frequent listener (${t[1]}-times)`,t[0]);return(this._options?.onListenerError||s.dz)(i),r.jG.None}if(this._disposed)return r.jG.None;t&&(e=e.bind(t));const n=new p(e);let o;this._leakageMon&&this._size>=Math.ceil(.2*this._leakageMon.threshold)&&(n.stack=d.create(),o=this._leakageMon.check(n.stack,this._size+1)),this._listeners?this._listeners instanceof p?(this._deliveryQueue??=new v,this._listeners=[this._listeners,n]):this._listeners.push(n):(this._options?.onWillAddFirstListener?.(this),this._listeners=n,this._options?.onDidAddFirstListener?.(this)),this._size++;const a=(0,r.s)((()=>{m?.unregister(a),o?.(),this._removeListener(n)}));if(i instanceof r.Cm?i.add(a):Array.isArray(i)&&i.push(a),m){const e=(new Error).stack.split("\n").slice(2,3).join("\n").trim(),t=/(file:|vscode-file:\/\/vscode-app)?(\/[^:]*:\d+:\d+)/.exec(e);m.register(a,t?.[2]??e,a)}return a},this._event}_removeListener(e){if(this._options?.onWillRemoveListener?.(this),!this._listeners)return;if(1===this._size)return this._listeners=void 0,this._options?.onDidRemoveLastListener?.(this),void(this._size=0);const t=this._listeners,i=t.indexOf(e);if(-1===i)throw console.log("disposed?",this._disposed),console.log("size?",this._size),console.log("arr?",JSON.stringify(this._listeners)),new Error("Attempted to dispose unknown listener");this._size--,t[i]=void 0;const s=this._deliveryQueue.current===this;if(2*this._size<=t.length){let e=0;for(let i=0;i0}}const _=()=>new v;class v{constructor(){this.i=-1,this.end=0}enqueue(e,t,i){this.i=0,this.end=i,this.current=e,this.value=t}reset(){this.i=this.end,this.current=void 0,this.value=void 0}}class C extends f{constructor(e){super(e),this._isPaused=0,this._eventQueue=new o.w,this._mergeFn=e?.merge}pause(){this._isPaused++}resume(){if(0!==this._isPaused&&0===--this._isPaused)if(this._mergeFn){if(this._eventQueue.size>0){const e=Array.from(this._eventQueue);this._eventQueue.clear(),super.fire(this._mergeFn(e))}}else for(;!this._isPaused&&0!==this._eventQueue.size;)super.fire(this._eventQueue.shift())}fire(e){this._size&&(0!==this._isPaused?this._eventQueue.push(e):super.fire(e))}}class b extends C{constructor(e){super(e),this._delay=e.delay??100}fire(e){this._handle||(this.pause(),this._handle=setTimeout((()=>{this._handle=void 0,this.resume()}),this._delay)),super.fire(e)}}class E extends f{constructor(e){super(e),this._queuedEvents=[],this._mergeFn=e?.merge}fire(e){this.hasListeners()&&(this._queuedEvents.push(e),1===this._queuedEvents.length&&queueMicrotask((()=>{this._mergeFn?super.fire(this._mergeFn(this._queuedEvents)):this._queuedEvents.forEach((e=>super.fire(e))),this._queuedEvents=[]})))}}class S{constructor(){this.hasListeners=!1,this.events=[],this.emitter=new f({onWillAddFirstListener:()=>this.onFirstListenerAdd(),onDidRemoveLastListener:()=>this.onLastListenerRemove()})}get event(){return this.emitter.event}add(e){const t={event:e,listener:null};this.events.push(t),this.hasListeners&&this.hook(t);return(0,r.s)((0,n.P)((()=>{this.hasListeners&&this.unhook(t);const e=this.events.indexOf(t);this.events.splice(e,1)})))}onFirstListenerAdd(){this.hasListeners=!0,this.events.forEach((e=>this.hook(e)))}onLastListenerRemove(){this.hasListeners=!1,this.events.forEach((e=>this.unhook(e)))}hook(e){e.listener=e.event((e=>this.emitter.fire(e)))}unhook(e){e.listener?.dispose(),e.listener=null}dispose(){this.emitter.dispose();for(const e of this.events)e.listener?.dispose();this.events=[]}}class y{constructor(){this.data=[]}wrapEvent(e,t,i){return(s,n,r)=>e((e=>{const r=this.data[this.data.length-1];if(!t)return void(r?r.buffers.push((()=>s.call(n,e))):s.call(n,e));const o=r;o?(o.items??=[],o.items.push(e),0===o.buffers.length&&r.buffers.push((()=>{o.reducedResult??=i?o.items.reduce(t,i):o.items.reduce(t),s.call(n,o.reducedResult)}))):s.call(n,t(i,e))}),void 0,r)}bufferEvents(e){const t={buffers:new Array};this.data.push(t);const i=e();return this.data.pop(),t.buffers.forEach((e=>e())),i}}class w{constructor(){this.listening=!1,this.inputEvent=l.None,this.inputEventListener=r.jG.None,this.emitter=new f({onDidAddFirstListener:()=>{this.listening=!0,this.inputEventListener=this.inputEvent(this.emitter.fire,this.emitter)},onDidRemoveLastListener:()=>{this.listening=!1,this.inputEventListener.dispose()}}),this.event=this.emitter.event}set input(e){this.inputEvent=e,this.listening&&(this.inputEventListener.dispose(),this.inputEventListener=e(this.emitter.fire,this.emitter))}dispose(){this.inputEventListener.dispose(),this.emitter.dispose()}}},79326:(e,t,i)=>{"use strict";i.d(t,{No:()=>u,TH:()=>a,Zn:()=>c,_1:()=>h,kb:()=>l});var s=i(74027),n=i(98067),r=i(91508);function o(e){return 47===e||92===e}function a(e){return e.replace(/[\\/]/g,s.SA.sep)}function l(e){return-1===e.indexOf("/")&&(e=a(e)),/^[a-zA-Z]:(\/|$)/.test(e)&&(e="/"+e),e}function c(e,t=s.SA.sep){if(!e)return"";const i=e.length,n=e.charCodeAt(0);if(o(n)){if(o(e.charCodeAt(1))&&!o(e.charCodeAt(2))){let s=3;const n=s;for(;se.length)return!1;if(i){if(!(0,r.ns)(e,t))return!1;if(t.length===e.length)return!0;let i=t.length;return t.charAt(t.length-1)===n&&i--,e.charAt(i)===n}return t.charAt(t.length-1)!==n&&(t+=n),0===e.indexOf(t)}function d(e){return e>=65&&e<=90||e>=97&&e<=122}function u(e,t=n.uF){return!!t&&(d(e.charCodeAt(0))&&58===e.charCodeAt(1))}},26690:(e,t,i)=>{"use strict";i.d(t,{ne:()=>ie,Nd:()=>se,Jo:()=>W,WJ:()=>V,dt:()=>ne,uU:()=>oe,Tt:()=>f,yr:()=>H,O:()=>B,WP:()=>p,dE:()=>_,J1:()=>O,or:()=>g});var s=i(74320);function n(e){const t=function(e){if(r=0,a(e,l,4352),r>0)return o.subarray(0,r);if(a(e,c,4449),r>0)return o.subarray(0,r);if(a(e,h,4520),r>0)return o.subarray(0,r);if(a(e,d,12593),r)return o.subarray(0,r);if(e>=44032&&e<=55203){const t=e-44032,i=t%588,s=Math.floor(t/588),n=Math.floor(i/28),u=i%28-1;if(s=0&&(u0)return o.subarray(0,r)}return}(e);if(t&&t.length>0)return new Uint32Array(t)}let r=0;const o=new Uint32Array(10);function a(e,t,i){e>=i&&e>8&&(o[r++]=e>>8&255);e>>16&&(o[r++]=e>>16&255)}(t[e-i])}const l=new Uint8Array([114,82,115,101,69,102,97,113,81,116,84,100,119,87,99,122,120,118,103]),c=new Uint16Array([107,111,105,79,106,112,117,80,104,27496,28520,27752,121,110,27246,28782,27758,98,109,27757,108]),h=new Uint16Array([114,82,29810,115,30579,26483,101,102,29286,24934,29030,29798,30822,30310,26470,97,113,29809,116,84,100,119,99,122,120,118,103]),d=new Uint16Array([114,82,29810,115,30579,26483,101,69,102,29286,24934,29030,29798,30822,30310,26470,97,113,81,29809,116,84,100,119,87,99,122,120,118,103,107,111,105,79,106,112,117,80,104,27496,28520,27752,121,110,27246,28782,27758,98,109,27757,108]);var u=i(91508);function g(...e){return function(t,i){for(let s=0,n=e.length;s0?[{start:0,end:t.length}]:[]:null}function f(e,t){const i=t.toLowerCase().indexOf(e.toLowerCase());return-1===i?null:[{start:i,end:i+e.length}]}function _(e,t){return v(e.toLowerCase(),t.toLowerCase(),0,0)}function v(e,t,i,s){if(i===e.length)return[];if(s===t.length)return null;if(e[i]===t[s]){let n=null;return(n=v(e,t,i+1,s+1))?k({start:s,end:s+1},n):null}return v(e,t,i,s+1)}function C(e){return 97<=e&&e<=122}function b(e){return 65<=e&&e<=90}function E(e){return 48<=e&&e<=57}function S(e){return 32===e||9===e||10===e||13===e}const y=new Set;function w(e){return S(e)||y.has(e)}function L(e,t){return e===t||w(e)&&w(t)}"()[]{}<>`'\"-/;:,.?!".split("").forEach((e=>y.add(e.charCodeAt(0))));const R=new Map;function T(e){if(R.has(e))return R.get(e);let t;const i=n(e);return i&&(t=i),R.set(e,t),t}function x(e){return C(e)||b(e)||E(e)}function k(e,t){return 0===t.length?t=[e]:e.end===t[0].start?t[0].start=e.start:t.unshift(e),t}function A(e,t){for(let i=t;i0&&!x(e.charCodeAt(i-1)))return i}return e.length}function N(e,t,i,s){if(i===e.length)return[];if(s===t.length)return null;if(e[i]!==t[s].toLowerCase())return null;{let n=null,r=s+1;for(n=N(e,t,i+1,s+1);!n&&(r=A(t,r))60&&(t=t.substring(0,60));const i=function(e){let t=0,i=0,s=0,n=0,r=0;for(let o=0;o.2&&t<.8&&s>.6&&n<.2}(i)){if(!function(e){const{upperPercent:t,lowerPercent:i}=e;return 0===i&&t>.6}(i))return null;t=t.toLowerCase()}let s=null,n=0;for(e=e.toLowerCase();n0&&w(e.charCodeAt(i-1)))return i;return e.length}const P=g(p,I,f),F=g(p,I,_),U=new s.qK(1e4);function H(e,t,i=!1){if("string"!==typeof e||"string"!==typeof t)return null;let s=U.get(e);s||(s=new RegExp(u.Bm(e),"i"),U.set(e,s));const n=s.exec(t);return n?[{start:n.index,end:n.index+n[0].length}]:i?F(e,t):P(e,t)}function B(e,t){const i=ne(e,e.toLowerCase(),0,t,t.toLowerCase(),0,{firstMatchCanBeWeak:!0,boostFullMatch:!0});return i?V(i):null}function W(e,t,i,s,n,r){const o=Math.min(13,e.length);for(;i1;s--){const n=e[s]+i,r=t[t.length-1];r&&r.end===n?r.end=n+1:t.push({start:n,end:n+1})}return t}const z=128;function G(){const e=[],t=[];for(let i=0;i<=z;i++)t[i]=0;for(let i=0;i<=z;i++)e.push(t.slice(0));return e}function j(e){const t=[];for(let i=0;i<=e;i++)t[i]=0;return t}const K=j(2*z),Y=j(2*z),q=G(),$=G(),Q=G(),X=!1;function Z(e,t,i,s,n){function r(e,t,i=" "){for(;e.lengthr(e,3))).join("|")}\n`;for(let a=0;a<=i;a++)o+=0===a?" |":`${t[a-1]}|`,o+=e[a].slice(0,n+1).map((e=>r(e.toString(),3))).join("|")+"\n";return o}function J(e,t){if(t<0||t>=e.length)return!1;const i=e.codePointAt(t);switch(i){case 95:case 45:case 46:case 32:case 47:case 92:case 39:case 34:case 58:case 36:case 60:case 62:case 40:case 41:case 91:case 93:case 123:case 125:return!0;case void 0:return!1;default:return!!u.Ss(i)}}function ee(e,t){if(t<0||t>=e.length)return!1;switch(e.charCodeAt(t)){case 32:case 9:return!0;default:return!1}}function te(e,t,i){return t[e]!==i[e]}var ie;!function(e){e.Default=[-100,0],e.isDefault=function(e){return!e||2===e.length&&-100===e[0]&&0===e[1]}}(ie||(ie={}));class se{static{this.default={boostFullMatch:!0,firstMatchCanBeWeak:!1}}constructor(e,t){this.firstMatchCanBeWeak=e,this.boostFullMatch=t}}function ne(e,t,i,s,n,r,o=se.default){const a=e.length>z?z:e.length,l=s.length>z?z:s.length;if(i>=a||r>=l||a-i>l-r)return;if(!function(e,t,i,s,n,r,o=!1){for(;t=i&&a>=s;)n[o]===r[a]&&(Y[o]=a,o--),a--}(a,l,i,r,t,n);let c=1,h=1,d=i,u=r;const g=[!1];for(c=1,d=i;do,v=_?$[c][h-1]+(q[c][h-1]>0?-5:0):0,C=u>o+1&&q[c][h-1]>0,b=C?$[c][h-2]+(q[c][h-2]>0?-5:0):0;if(C&&(!_||b>=v)&&(!m||b>=f))$[c][h]=b,Q[c][h]=3,q[c][h]=0;else if(_&&(!m||v>=f))$[c][h]=v,Q[c][h]=2,q[c][h]=0;else{if(!m)throw new Error("not possible");$[c][h]=f,Q[c][h]=1,q[c][h]=q[c-1][h-1]+1}}}if(X&&function(e,t,i,s){e=e.substr(t),i=i.substr(s),console.log(Z($,e,e.length,i,i.length)),console.log(Z(Q,e,e.length,i,i.length)),console.log(Z(q,e,e.length,i,i.length))}(e,i,s,r),!g[0]&&!o.firstMatchCanBeWeak)return;c--,h--;const p=[$[c][h],r];let m=0,f=0;for(;c>=1;){let e=h;do{const t=Q[c][e];if(3===t)e-=2;else{if(2!==t)break;e-=1}}while(e>=1);m>1&&t[i+c-1]===n[r+h-1]&&!te(e+r-1,s,n)&&m+1>q[c][e]&&(e=h),e===h?m++:m=1,f||(f=e),c--,h=e-1,p.push(h)}l-r===a&&o.boostFullMatch&&(p[0]+=2);const _=f-a;return p[0]-=_,p}function re(e,t,i,s,n,r,o,a,l,c,h){if(t[i]!==r[o])return Number.MIN_SAFE_INTEGER;let d=1,u=!1;return o===i-s?d=e[i]===n[o]?7:5:!te(o,n,r)||0!==o&&te(o-1,n,r)?!J(r,o)||0!==o&&J(r,o-1)?(J(r,o-1)||ee(r,o-1))&&(d=5,u=!0):d=5:(d=e[i]===n[o]?7:5,u=!0),d>1&&i===s&&(h[0]=!0),u||(u=te(o,n,r)||J(r,o-1)||ee(r,o-1)),i===s?o>l&&(d-=u?3:5):d+=c?u?2:0:u?0:1,o+1===a&&(d-=u?3:5),d}function oe(e,t,i,s,n,r,o){return function(e,t,i,s,n,r,o,a){let l=ne(e,t,i,s,n,r,a);if(l&&!o)return l;if(e.length>=3){const t=Math.min(7,e.length-1);for(let o=i+1;ol[0])&&(l=e))}}}return l}(e,t,i,s,n,r,!0,o)}function ae(e,t){if(t+1>=e.length)return;const i=e[t],s=e[t+1];return i!==s?e.slice(0,t)+s+i+e.slice(t+2):void 0}},6921:(e,t,i)=>{"use strict";function s(e,t){const i=this;let s,n=!1;return function(){if(n)return s;if(n=!0,t)try{s=e.apply(i,arguments)}finally{t()}else s=e.apply(i,arguments);return s}}i.d(t,{P:()=>s})},46958:(e,t,i)=>{"use strict";i.d(t,{YW:()=>A,qg:()=>N});var s=i(90766),n=i(79326),r=i(74320),o=i(74027),a=i(98067),l=i(91508);const c="**",h="/",d="[/\\\\]",u="[^/\\\\]",g=/\//g;function p(e,t){switch(e){case 0:return"";case 1:return`${u}*?`;default:return`(?:${d}|${u}+${d}${t?`|${d}${u}+`:""})*?`}}function m(e,t){if(!e)return[];const i=[];let s=!1,n=!1,r="";for(const o of e){switch(o){case t:if(!s&&!n){i.push(r),r="";continue}break;case"{":s=!0;break;case"}":s=!1;break;case"[":n=!0;break;case"]":n=!1}r+=o}return r&&i.push(r),i}function f(e){if(!e)return"";let t="";const i=m(e,h);if(i.every((e=>e===c)))t=".*";else{let e=!1;i.forEach(((s,n)=>{if(s===c){if(e)return;t+=p(2,n===i.length-1)}else{let e=!1,r="",o=!1,a="";for(const i of s)if("}"!==i&&e)r+=i;else if(!o||"]"===i&&a)switch(i){case"{":e=!0;continue;case"[":o=!0;continue;case"}":{const i=`(?:${m(r,",").map((e=>f(e))).join("|")})`;t+=i,e=!1,r="";break}case"]":t+="["+a+"]",o=!1,a="";break;case"?":t+=u;continue;case"*":t+=p(1);continue;default:t+=(0,l.bm)(i)}else{let e;e="-"===i?i:"^"!==i&&"!"!==i||a?i===h?"":(0,l.bm)(i):"^",a+=e}nR(e,t))).filter((e=>e!==L)),e),s=i.length;if(!s)return L;if(1===s)return i[0];const n=function(t,s){for(let n=0,r=i.length;n!!e.allBasenames));r&&(n.allBasenames=r.allBasenames);const o=i.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);o.length&&(n.allPaths=o);return n}(i,t):(n=E.exec(x(i,t)))?k(n[1].substr(1),i,!0):(n=S.exec(x(i,t)))?k(n[1],i,!1):function(e){try{const t=new RegExp(`^${f(e)}$`);return function(i){return t.lastIndex=0,"string"===typeof i&&t.test(i)?e:null}}catch(t){return L}}(i),y.set(s,r)),T(r,e)}function T(e,t){if("string"===typeof t)return e;const i=function(i,s){return(0,n._1)(i,t.base,!a.j9)?e((0,l.NB)(i.substr(t.base.length),o.Vn),s):null};return i.allBasenames=e.allBasenames,i.allPaths=e.allPaths,i.basenames=e.basenames,i.patterns=e.patterns,i}function x(e,t){return t.trimForExclusions&&e.endsWith("/**")?e.substr(0,e.length-2):e}function k(e,t,i){const s=o.Vn===o.SA.sep,n=s?e:e.replace(g,o.Vn),r=o.Vn+n,a=o.SA.sep+e;let l;return l=i?function(i,o){return"string"!==typeof i||i!==n&&!i.endsWith(r)&&(s||i!==e&&!i.endsWith(a))?null:t}:function(i,r){return"string"!==typeof i||i!==n&&(s||i!==e)?null:t},l.allPaths=[(i?"*/":"./")+e],l}function A(e,t,i){return!(!e||"string"!==typeof t)&&N(e)(t,void 0,i)}function N(e,t={}){if(!e)return w;if("string"===typeof e||function(e){const t=e;if(!t)return!1;return"string"===typeof t.base&&"string"===typeof t.pattern}(e)){const i=R(e,t);if(i===L)return w;const s=function(e,t){return!!i(e,t)};return i.allBasenames&&(s.allBasenames=i.allBasenames),i.allPaths&&(s.allPaths=i.allPaths),s}return function(e,t){const i=I(Object.getOwnPropertyNames(e).map((i=>function(e,t,i){if(!1===t)return L;const n=R(e,i);if(n===L)return L;if("boolean"===typeof t)return n;if(t){const i=t.when;if("string"===typeof i){const t=(t,r,o,a)=>{if(!a||!n(t,r))return null;const l=a(i.replace("$(basename)",(()=>o)));return(0,s.Qg)(l)?l.then((t=>t?e:null)):l?e:null};return t.requiresSiblings=!0,t}}return n}(i,e[i],t))).filter((e=>e!==L))),n=i.length;if(!n)return L;if(!i.some((e=>!!e.requiresSiblings))){if(1===n)return i[0];const e=function(e,t){let n;for(let r=0,o=i.length;r{for(const e of n){const t=await e;if("string"===typeof t)return t}return null})():null},t=i.find((e=>!!e.allBasenames));t&&(e.allBasenames=t.allBasenames);const r=i.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);return r.length&&(e.allPaths=r),e}const r=function(e,t,n){let r,a;for(let l=0,c=i.length;l{for(const e of a){const t=await e;if("string"===typeof t)return t}return null})():null},a=i.find((e=>!!e.allBasenames));a&&(r.allBasenames=a.allBasenames);const l=i.reduce(((e,t)=>t.allPaths?e.concat(t.allPaths):e),[]);l.length&&(r.allPaths=l);return r}(e,t)}function I(e,t){const i=e.filter((e=>!!e.basenames));if(i.length<2)return e;const s=i.reduce(((e,t)=>{const i=t.basenames;return i?e.concat(i):e}),[]);let n;if(t){n=[];for(let e=0,i=s.length;e{const i=t.patterns;return i?e.concat(i):e}),[]);const r=function(e,t){if("string"!==typeof e)return null;if(!t){let i;for(i=e.length;i>0;i--){const t=e.charCodeAt(i-1);if(47===t||92===t)break}t=e.substr(i)}const i=s.indexOf(t);return-1!==i?n[i]:null};r.basenames=s,r.patterns=n,r.allBasenames=s;const o=e.filter((e=>!e.basenames));return o.push(r),o}},85600:(e,t,i)=>{"use strict";i.d(t,{e2:()=>a,sN:()=>r,tW:()=>n,v7:()=>d});var s=i(91508);function n(e){return r(e,0)}function r(e,t){switch(typeof e){case"object":return null===e?o(349,t):Array.isArray(e)?(i=e,s=o(104579,s=t),i.reduce(((e,t)=>r(t,e)),s)):function(e,t){return t=o(181387,t),Object.keys(e).sort().reduce(((t,i)=>(t=a(i,t),r(e[i],t))),t)}(e,t);case"string":return a(e,t);case"boolean":return function(e,t){return o(e?433:863,t)}(e,t);case"number":return o(e,t);case"undefined":return o(937,t);default:return o(617,t)}var i,s}function o(e,t){return(t<<5)-t+e|0}function a(e,t){t=o(149417,t);for(let i=0,s=e.length;i>>s)>>>0}function c(e,t=0,i=e.byteLength,s=0){for(let n=0;ne.toString(16).padStart(2,"0"))).join(""):function(e,t,i="0"){for(;e.length>>0).toString(16),t/4)}class d{static{this._bigBlock32=new DataView(new ArrayBuffer(320))}constructor(){this._h0=1732584193,this._h1=4023233417,this._h2=2562383102,this._h3=271733878,this._h4=3285377520,this._buff=new Uint8Array(67),this._buffDV=new DataView(this._buff.buffer),this._buffLen=0,this._totalLen=0,this._leftoverHighSurrogate=0,this._finished=!1}update(e){const t=e.length;if(0===t)return;const i=this._buff;let n,r,o=this._buffLen,a=this._leftoverHighSurrogate;for(0!==a?(n=a,r=-1,a=0):(n=e.charCodeAt(0),r=0);;){let l=n;if(s.pc(n)){if(!(r+1>>6,e[t++]=128|(63&i)>>>0):i<65536?(e[t++]=224|(61440&i)>>>12,e[t++]=128|(4032&i)>>>6,e[t++]=128|(63&i)>>>0):(e[t++]=240|(1835008&i)>>>18,e[t++]=128|(258048&i)>>>12,e[t++]=128|(4032&i)>>>6,e[t++]=128|(63&i)>>>0),t>=64&&(this._step(),t-=64,this._totalLen+=64,e[0]=e[64],e[1]=e[65],e[2]=e[66]),t}digest(){return this._finished||(this._finished=!0,this._leftoverHighSurrogate&&(this._leftoverHighSurrogate=0,this._buffLen=this._push(this._buff,this._buffLen,65533)),this._totalLen+=this._buffLen,this._wrapUp()),h(this._h0)+h(this._h1)+h(this._h2)+h(this._h3)+h(this._h4)}_wrapUp(){this._buff[this._buffLen++]=128,c(this._buff,this._buffLen),this._buffLen>56&&(this._step(),c(this._buff));const e=8*this._totalLen;this._buffDV.setUint32(56,Math.floor(e/4294967296),!1),this._buffDV.setUint32(60,e%4294967296,!1),this._step()}_step(){const e=d._bigBlock32,t=this._buffDV;for(let l=0;l<64;l+=4)e.setUint32(l,t.getUint32(l,!1),!1);for(let d=64;d<320;d+=4)e.setUint32(d,l(e.getUint32(d-12,!1)^e.getUint32(d-32,!1)^e.getUint32(d-56,!1)^e.getUint32(d-64,!1),1),!1);let i,s,n,r=this._h0,o=this._h1,a=this._h2,c=this._h3,h=this._h4;for(let d=0;d<80;d++)d<20?(i=o&a|~o&c,s=1518500249):d<40?(i=o^a^c,s=1859775393):d<60?(i=o&a|o&c|a&c,s=2400959708):(i=o^a^c,s=3395469782),n=l(r,5)+i+h+s+e.getUint32(4*d,!1)&4294967295,h=c,c=a,a=l(o,30),o=r,r=n;this._h0=this._h0+r&4294967295,this._h1=this._h1+o&4294967295,this._h2=this._h2+a&4294967295,this._h3=this._h3+c&4294967295,this._h4=this._h4+h&4294967295}}},8995:(e,t,i)=>{"use strict";i.d(t,{k:()=>s});class s{static{this.sep="."}static{this.None=new s("@@none@@")}static{this.Empty=new s("")}constructor(e){this.value=e}equals(e){return this.value===e.value}contains(e){return this.equals(e)||""===this.value||e.value.startsWith(this.value+s.sep)}intersects(e){return this.contains(e)||e.contains(this)}append(...e){return new s((this.value?[this.value,...e]:e).join(s.sep))}}},30076:(e,t,i)=>{"use strict";i.d(t,{O:()=>r,e:()=>n});var s=i(59911);function n(){return s._K&&!!s._K.VSCODE_DEV}function r(e){if(n()){const t=function(){o||(o=new Set);const e=globalThis;e.$hotReload_applyNewExports||(e.$hotReload_applyNewExports=e=>{const t={config:{mode:void 0},...e},i=[];for(const s of o){const e=s(t);e&&i.push(e)}if(i.length>0)return e=>{let t=!1;for(const s of i)s(e)&&(t=!0);return t}});return o}();return t.add(e),{dispose(){t.delete(e)}}}return{dispose(){}}}let o;n()&&r((({oldExports:e,newSrc:t,config:i})=>{if("patch-prototype"===i.mode)return t=>{for(const i in t){const s=t[i];if(console.log(`[hot-reload] Patching prototype methods of '${i}'`,{exportedItem:s}),"function"===typeof s&&s.prototype){const n=e[i];if(n){for(const e of Object.getOwnPropertyNames(s.prototype)){const t=Object.getOwnPropertyDescriptor(s.prototype,e),r=Object.getOwnPropertyDescriptor(n.prototype,e);t?.value?.toString()!==r?.value?.toString()&&console.log(`[hot-reload] Patching prototype method '${i}.${e}'`),Object.defineProperty(n.prototype,e,t)}t[i]=n}}}return!0}}))},41127:(e,t,i)=>{"use strict";i.d(t,{b:()=>r});var s=i(30076),n=i(31308);function r(e,t){return function(e,t){if((0,s.e)()){(0,n.yQ)("reload",(t=>(0,s.O)((({oldExports:i})=>{if([...Object.values(i)].some((t=>e.includes(t))))return e=>(t(void 0),!0)})))).read(t)}}([e],t),e}},16980:(e,t,i)=>{"use strict";i.d(t,{Bc:()=>l,VS:()=>h,_W:()=>g,it:()=>c,nI:()=>p,nK:()=>d,oO:()=>u});var s=i(64383),n=i(37882),r=i(89403),o=i(91508),a=i(79400);class l{constructor(e="",t=!1){if(this.value=e,"string"!==typeof this.value)throw(0,s.Qg)("value");"boolean"===typeof t?(this.isTrusted=t,this.supportThemeIcons=!1,this.supportHtml=!1):(this.isTrusted=t.isTrusted??void 0,this.supportThemeIcons=t.supportThemeIcons??!1,this.supportHtml=t.supportHtml??!1)}appendText(e,t=0){var i;return this.value+=(i=this.supportThemeIcons?(0,n.m2)(e):e,i.replace(/[\\`*_{}[\]()#+\-!~]/g,"\\$&")).replace(/([ \t]+)/g,((e,t)=>" ".repeat(t.length))).replace(/\>/gm,"\\>").replace(/\n/g,1===t?"\\\n":"\n\n"),this}appendMarkdown(e){return this.value+=e,this}appendCodeblock(e,t){return this.value+=`\n${function(e,t){const i=e.match(/^`+/gm)?.reduce(((e,t)=>e.length>t.length?e:t)).length??0,s=i>=3?i+1:3;return[`${"`".repeat(s)}${t}`,e,`${"`".repeat(s)}`].join("\n")}(t,e)}\n`,this}appendLink(e,t,i){return this.value+="[",this.value+=this._escape(t,"]"),this.value+="](",this.value+=this._escape(String(e),")"),i&&(this.value+=` "${this._escape(this._escape(i,'"'),")")}"`),this.value+=")",this}_escape(e,t){const i=new RegExp((0,o.bm)(t),"g");return e.replace(i,((t,i)=>"\\"!==e.charAt(i-1)?`\\${t}`:t))}}function c(e){return h(e)?!e.value:!Array.isArray(e)||e.every(c)}function h(e){return e instanceof l||!(!e||"object"!==typeof e)&&("string"===typeof e.value&&("boolean"===typeof e.isTrusted||"object"===typeof e.isTrusted||void 0===e.isTrusted)&&("boolean"===typeof e.supportThemeIcons||void 0===e.supportThemeIcons))}function d(e,t){return e===t||!(!e||!t)&&(e.value===t.value&&e.isTrusted===t.isTrusted&&e.supportThemeIcons===t.supportThemeIcons&&e.supportHtml===t.supportHtml&&(e.baseUri===t.baseUri||!!e.baseUri&&!!t.baseUri&&(0,r.n4)(a.r.from(e.baseUri),a.r.from(t.baseUri))))}function u(e){return e.replace(/"/g,""")}function g(e){return e?e.replace(/\\([\\`*_{}[\]()#+\-.!~])/g,"$1"):e}function p(e){const t=[],i=e.split("|").map((e=>e.trim()));e=i[0];const s=i[1];if(s){const e=/height=(\d+)/.exec(s),i=/width=(\d+)/.exec(s),n=e?e[1]:"",r=i?i[1]:"",o=isFinite(parseInt(r)),a=isFinite(parseInt(n));o&&t.push(`width="${r}"`),a&&t.push(`height="${n}"`)}return{href:e,dimensions:t}}},37882:(e,t,i)=>{"use strict";i.d(t,{R$:()=>p,_k:()=>f,m2:()=>c,pS:()=>g,pz:()=>_,sA:()=>d});var s=i(26690),n=i(91508),r=i(25689);const o="$(",a=new RegExp(`\\$\\(${r.L.iconNameExpression}(?:${r.L.iconModifierExpression})?\\)`,"g"),l=new RegExp(`(\\\\)?${a.source}`,"g");function c(e){return e.replace(l,((e,t)=>t?e:`\\${e}`))}const h=new RegExp(`\\\\${a.source}`,"g");function d(e){return e.replace(h,(e=>`\\${e}`))}const u=new RegExp(`(\\s)?(\\\\)?${a.source}(\\s)?`,"g");function g(e){return-1===e.indexOf(o)?e:e.replace(u,((e,t,i,s)=>i?e:t||s||""))}function p(e){return e?e.replace(/\$\((.*?)\)/g,((e,t)=>` ${t} `)).trim():""}const m=new RegExp(`\\$\\(${r.L.iconNameCharacter}+\\)`,"g");function f(e){m.lastIndex=0;let t="";const i=[];let s=0;for(;;){const n=m.lastIndex,r=m.exec(e),o=e.substring(n,r?.index);if(o.length>0){t+=o;for(let e=0;e{"use strict";i.d(t,{n:()=>s,r:()=>n});class s{constructor(e){this._prefix=e,this._lastId=0}nextId(){return this._prefix+ ++this._lastId}}const n=new s("id#")},2299:(e,t,i)=>{"use strict";i.d(t,{M:()=>n});var s=i(41234);const n=new class{constructor(){this._onDidChange=new s.vl,this.onDidChange=this._onDidChange.event,this._enabled=!0}get enabled(){return this._enabled}enable(){this._enabled=!0,this._onDidChange.fire()}disable(){this._enabled=!1,this._onDidChange.fire()}}},42522:(e,t,i)=>{"use strict";var s;i.d(t,{f:()=>s}),function(e){function t(e){return e&&"object"===typeof e&&"function"===typeof e[Symbol.iterator]}e.is=t;const i=Object.freeze([]);function*s(e){yield e}e.empty=function(){return i},e.single=s,e.wrap=function(e){return t(e)?e:s(e)},e.from=function(e){return e||i},e.reverse=function*(e){for(let t=e.length-1;t>=0;t--)yield e[t]},e.isEmpty=function(e){return!e||!0===e[Symbol.iterator]().next().done},e.first=function(e){return e[Symbol.iterator]().next().value},e.some=function(e,t){let i=0;for(const s of e)if(t(s,i++))return!0;return!1},e.find=function(e,t){for(const i of e)if(t(i))return i},e.filter=function*(e,t){for(const i of e)t(i)&&(yield i)},e.map=function*(e,t){let i=0;for(const s of e)yield t(s,i++)},e.flatMap=function*(e,t){let i=0;for(const s of e)yield*t(s,i++)},e.concat=function*(...e){for(const t of e)yield*t},e.reduce=function(e,t,i){let s=i;for(const n of e)s=t(s,n);return s},e.slice=function*(e,t,i=e.length){for(t<0&&(t+=e.length),i<0?i+=e.length:i>e.length&&(i=e.length);tn}]},e.asyncToArray=async function(e){const t=[];for await(const i of e)t.push(i);return Promise.resolve(t)}}(s||(s={}))},24939:(e,t,i)=>{"use strict";i.d(t,{Fo:()=>u,YM:()=>p,m5:()=>m,uw:()=>a});class s{constructor(){this._keyCodeToStr=[],this._strToKeyCode=Object.create(null)}define(e,t){this._keyCodeToStr[e]=t,this._strToKeyCode[t.toLowerCase()]=e}keyCodeToStr(e){return this._keyCodeToStr[e]}strToKeyCode(e){return this._strToKeyCode[e.toLowerCase()]||0}}const n=new s,r=new s,o=new s,a=new Array(230),l={},c=[],h=Object.create(null),d=Object.create(null),u=[],g=[];for(let f=0;f<=193;f++)u[f]=-1;for(let f=0;f<=132;f++)g[f]=-1;var p;function m(e,t){return(e|(65535&t)<<16>>>0)>>>0}!function(){const e="",t=[[1,0,"None",0,"unknown",0,"VK_UNKNOWN",e,e],[1,1,"Hyper",0,e,0,e,e,e],[1,2,"Super",0,e,0,e,e,e],[1,3,"Fn",0,e,0,e,e,e],[1,4,"FnLock",0,e,0,e,e,e],[1,5,"Suspend",0,e,0,e,e,e],[1,6,"Resume",0,e,0,e,e,e],[1,7,"Turbo",0,e,0,e,e,e],[1,8,"Sleep",0,e,0,"VK_SLEEP",e,e],[1,9,"WakeUp",0,e,0,e,e,e],[0,10,"KeyA",31,"A",65,"VK_A",e,e],[0,11,"KeyB",32,"B",66,"VK_B",e,e],[0,12,"KeyC",33,"C",67,"VK_C",e,e],[0,13,"KeyD",34,"D",68,"VK_D",e,e],[0,14,"KeyE",35,"E",69,"VK_E",e,e],[0,15,"KeyF",36,"F",70,"VK_F",e,e],[0,16,"KeyG",37,"G",71,"VK_G",e,e],[0,17,"KeyH",38,"H",72,"VK_H",e,e],[0,18,"KeyI",39,"I",73,"VK_I",e,e],[0,19,"KeyJ",40,"J",74,"VK_J",e,e],[0,20,"KeyK",41,"K",75,"VK_K",e,e],[0,21,"KeyL",42,"L",76,"VK_L",e,e],[0,22,"KeyM",43,"M",77,"VK_M",e,e],[0,23,"KeyN",44,"N",78,"VK_N",e,e],[0,24,"KeyO",45,"O",79,"VK_O",e,e],[0,25,"KeyP",46,"P",80,"VK_P",e,e],[0,26,"KeyQ",47,"Q",81,"VK_Q",e,e],[0,27,"KeyR",48,"R",82,"VK_R",e,e],[0,28,"KeyS",49,"S",83,"VK_S",e,e],[0,29,"KeyT",50,"T",84,"VK_T",e,e],[0,30,"KeyU",51,"U",85,"VK_U",e,e],[0,31,"KeyV",52,"V",86,"VK_V",e,e],[0,32,"KeyW",53,"W",87,"VK_W",e,e],[0,33,"KeyX",54,"X",88,"VK_X",e,e],[0,34,"KeyY",55,"Y",89,"VK_Y",e,e],[0,35,"KeyZ",56,"Z",90,"VK_Z",e,e],[0,36,"Digit1",22,"1",49,"VK_1",e,e],[0,37,"Digit2",23,"2",50,"VK_2",e,e],[0,38,"Digit3",24,"3",51,"VK_3",e,e],[0,39,"Digit4",25,"4",52,"VK_4",e,e],[0,40,"Digit5",26,"5",53,"VK_5",e,e],[0,41,"Digit6",27,"6",54,"VK_6",e,e],[0,42,"Digit7",28,"7",55,"VK_7",e,e],[0,43,"Digit8",29,"8",56,"VK_8",e,e],[0,44,"Digit9",30,"9",57,"VK_9",e,e],[0,45,"Digit0",21,"0",48,"VK_0",e,e],[1,46,"Enter",3,"Enter",13,"VK_RETURN",e,e],[1,47,"Escape",9,"Escape",27,"VK_ESCAPE",e,e],[1,48,"Backspace",1,"Backspace",8,"VK_BACK",e,e],[1,49,"Tab",2,"Tab",9,"VK_TAB",e,e],[1,50,"Space",10,"Space",32,"VK_SPACE",e,e],[0,51,"Minus",88,"-",189,"VK_OEM_MINUS","-","OEM_MINUS"],[0,52,"Equal",86,"=",187,"VK_OEM_PLUS","=","OEM_PLUS"],[0,53,"BracketLeft",92,"[",219,"VK_OEM_4","[","OEM_4"],[0,54,"BracketRight",94,"]",221,"VK_OEM_6","]","OEM_6"],[0,55,"Backslash",93,"\\",220,"VK_OEM_5","\\","OEM_5"],[0,56,"IntlHash",0,e,0,e,e,e],[0,57,"Semicolon",85,";",186,"VK_OEM_1",";","OEM_1"],[0,58,"Quote",95,"'",222,"VK_OEM_7","'","OEM_7"],[0,59,"Backquote",91,"`",192,"VK_OEM_3","`","OEM_3"],[0,60,"Comma",87,",",188,"VK_OEM_COMMA",",","OEM_COMMA"],[0,61,"Period",89,".",190,"VK_OEM_PERIOD",".","OEM_PERIOD"],[0,62,"Slash",90,"/",191,"VK_OEM_2","/","OEM_2"],[1,63,"CapsLock",8,"CapsLock",20,"VK_CAPITAL",e,e],[1,64,"F1",59,"F1",112,"VK_F1",e,e],[1,65,"F2",60,"F2",113,"VK_F2",e,e],[1,66,"F3",61,"F3",114,"VK_F3",e,e],[1,67,"F4",62,"F4",115,"VK_F4",e,e],[1,68,"F5",63,"F5",116,"VK_F5",e,e],[1,69,"F6",64,"F6",117,"VK_F6",e,e],[1,70,"F7",65,"F7",118,"VK_F7",e,e],[1,71,"F8",66,"F8",119,"VK_F8",e,e],[1,72,"F9",67,"F9",120,"VK_F9",e,e],[1,73,"F10",68,"F10",121,"VK_F10",e,e],[1,74,"F11",69,"F11",122,"VK_F11",e,e],[1,75,"F12",70,"F12",123,"VK_F12",e,e],[1,76,"PrintScreen",0,e,0,e,e,e],[1,77,"ScrollLock",84,"ScrollLock",145,"VK_SCROLL",e,e],[1,78,"Pause",7,"PauseBreak",19,"VK_PAUSE",e,e],[1,79,"Insert",19,"Insert",45,"VK_INSERT",e,e],[1,80,"Home",14,"Home",36,"VK_HOME",e,e],[1,81,"PageUp",11,"PageUp",33,"VK_PRIOR",e,e],[1,82,"Delete",20,"Delete",46,"VK_DELETE",e,e],[1,83,"End",13,"End",35,"VK_END",e,e],[1,84,"PageDown",12,"PageDown",34,"VK_NEXT",e,e],[1,85,"ArrowRight",17,"RightArrow",39,"VK_RIGHT","Right",e],[1,86,"ArrowLeft",15,"LeftArrow",37,"VK_LEFT","Left",e],[1,87,"ArrowDown",18,"DownArrow",40,"VK_DOWN","Down",e],[1,88,"ArrowUp",16,"UpArrow",38,"VK_UP","Up",e],[1,89,"NumLock",83,"NumLock",144,"VK_NUMLOCK",e,e],[1,90,"NumpadDivide",113,"NumPad_Divide",111,"VK_DIVIDE",e,e],[1,91,"NumpadMultiply",108,"NumPad_Multiply",106,"VK_MULTIPLY",e,e],[1,92,"NumpadSubtract",111,"NumPad_Subtract",109,"VK_SUBTRACT",e,e],[1,93,"NumpadAdd",109,"NumPad_Add",107,"VK_ADD",e,e],[1,94,"NumpadEnter",3,e,0,e,e,e],[1,95,"Numpad1",99,"NumPad1",97,"VK_NUMPAD1",e,e],[1,96,"Numpad2",100,"NumPad2",98,"VK_NUMPAD2",e,e],[1,97,"Numpad3",101,"NumPad3",99,"VK_NUMPAD3",e,e],[1,98,"Numpad4",102,"NumPad4",100,"VK_NUMPAD4",e,e],[1,99,"Numpad5",103,"NumPad5",101,"VK_NUMPAD5",e,e],[1,100,"Numpad6",104,"NumPad6",102,"VK_NUMPAD6",e,e],[1,101,"Numpad7",105,"NumPad7",103,"VK_NUMPAD7",e,e],[1,102,"Numpad8",106,"NumPad8",104,"VK_NUMPAD8",e,e],[1,103,"Numpad9",107,"NumPad9",105,"VK_NUMPAD9",e,e],[1,104,"Numpad0",98,"NumPad0",96,"VK_NUMPAD0",e,e],[1,105,"NumpadDecimal",112,"NumPad_Decimal",110,"VK_DECIMAL",e,e],[0,106,"IntlBackslash",97,"OEM_102",226,"VK_OEM_102",e,e],[1,107,"ContextMenu",58,"ContextMenu",93,e,e,e],[1,108,"Power",0,e,0,e,e,e],[1,109,"NumpadEqual",0,e,0,e,e,e],[1,110,"F13",71,"F13",124,"VK_F13",e,e],[1,111,"F14",72,"F14",125,"VK_F14",e,e],[1,112,"F15",73,"F15",126,"VK_F15",e,e],[1,113,"F16",74,"F16",127,"VK_F16",e,e],[1,114,"F17",75,"F17",128,"VK_F17",e,e],[1,115,"F18",76,"F18",129,"VK_F18",e,e],[1,116,"F19",77,"F19",130,"VK_F19",e,e],[1,117,"F20",78,"F20",131,"VK_F20",e,e],[1,118,"F21",79,"F21",132,"VK_F21",e,e],[1,119,"F22",80,"F22",133,"VK_F22",e,e],[1,120,"F23",81,"F23",134,"VK_F23",e,e],[1,121,"F24",82,"F24",135,"VK_F24",e,e],[1,122,"Open",0,e,0,e,e,e],[1,123,"Help",0,e,0,e,e,e],[1,124,"Select",0,e,0,e,e,e],[1,125,"Again",0,e,0,e,e,e],[1,126,"Undo",0,e,0,e,e,e],[1,127,"Cut",0,e,0,e,e,e],[1,128,"Copy",0,e,0,e,e,e],[1,129,"Paste",0,e,0,e,e,e],[1,130,"Find",0,e,0,e,e,e],[1,131,"AudioVolumeMute",117,"AudioVolumeMute",173,"VK_VOLUME_MUTE",e,e],[1,132,"AudioVolumeUp",118,"AudioVolumeUp",175,"VK_VOLUME_UP",e,e],[1,133,"AudioVolumeDown",119,"AudioVolumeDown",174,"VK_VOLUME_DOWN",e,e],[1,134,"NumpadComma",110,"NumPad_Separator",108,"VK_SEPARATOR",e,e],[0,135,"IntlRo",115,"ABNT_C1",193,"VK_ABNT_C1",e,e],[1,136,"KanaMode",0,e,0,e,e,e],[0,137,"IntlYen",0,e,0,e,e,e],[1,138,"Convert",0,e,0,e,e,e],[1,139,"NonConvert",0,e,0,e,e,e],[1,140,"Lang1",0,e,0,e,e,e],[1,141,"Lang2",0,e,0,e,e,e],[1,142,"Lang3",0,e,0,e,e,e],[1,143,"Lang4",0,e,0,e,e,e],[1,144,"Lang5",0,e,0,e,e,e],[1,145,"Abort",0,e,0,e,e,e],[1,146,"Props",0,e,0,e,e,e],[1,147,"NumpadParenLeft",0,e,0,e,e,e],[1,148,"NumpadParenRight",0,e,0,e,e,e],[1,149,"NumpadBackspace",0,e,0,e,e,e],[1,150,"NumpadMemoryStore",0,e,0,e,e,e],[1,151,"NumpadMemoryRecall",0,e,0,e,e,e],[1,152,"NumpadMemoryClear",0,e,0,e,e,e],[1,153,"NumpadMemoryAdd",0,e,0,e,e,e],[1,154,"NumpadMemorySubtract",0,e,0,e,e,e],[1,155,"NumpadClear",131,"Clear",12,"VK_CLEAR",e,e],[1,156,"NumpadClearEntry",0,e,0,e,e,e],[1,0,e,5,"Ctrl",17,"VK_CONTROL",e,e],[1,0,e,4,"Shift",16,"VK_SHIFT",e,e],[1,0,e,6,"Alt",18,"VK_MENU",e,e],[1,0,e,57,"Meta",91,"VK_COMMAND",e,e],[1,157,"ControlLeft",5,e,0,"VK_LCONTROL",e,e],[1,158,"ShiftLeft",4,e,0,"VK_LSHIFT",e,e],[1,159,"AltLeft",6,e,0,"VK_LMENU",e,e],[1,160,"MetaLeft",57,e,0,"VK_LWIN",e,e],[1,161,"ControlRight",5,e,0,"VK_RCONTROL",e,e],[1,162,"ShiftRight",4,e,0,"VK_RSHIFT",e,e],[1,163,"AltRight",6,e,0,"VK_RMENU",e,e],[1,164,"MetaRight",57,e,0,"VK_RWIN",e,e],[1,165,"BrightnessUp",0,e,0,e,e,e],[1,166,"BrightnessDown",0,e,0,e,e,e],[1,167,"MediaPlay",0,e,0,e,e,e],[1,168,"MediaRecord",0,e,0,e,e,e],[1,169,"MediaFastForward",0,e,0,e,e,e],[1,170,"MediaRewind",0,e,0,e,e,e],[1,171,"MediaTrackNext",124,"MediaTrackNext",176,"VK_MEDIA_NEXT_TRACK",e,e],[1,172,"MediaTrackPrevious",125,"MediaTrackPrevious",177,"VK_MEDIA_PREV_TRACK",e,e],[1,173,"MediaStop",126,"MediaStop",178,"VK_MEDIA_STOP",e,e],[1,174,"Eject",0,e,0,e,e,e],[1,175,"MediaPlayPause",127,"MediaPlayPause",179,"VK_MEDIA_PLAY_PAUSE",e,e],[1,176,"MediaSelect",128,"LaunchMediaPlayer",181,"VK_MEDIA_LAUNCH_MEDIA_SELECT",e,e],[1,177,"LaunchMail",129,"LaunchMail",180,"VK_MEDIA_LAUNCH_MAIL",e,e],[1,178,"LaunchApp2",130,"LaunchApp2",183,"VK_MEDIA_LAUNCH_APP2",e,e],[1,179,"LaunchApp1",0,e,0,"VK_MEDIA_LAUNCH_APP1",e,e],[1,180,"SelectTask",0,e,0,e,e,e],[1,181,"LaunchScreenSaver",0,e,0,e,e,e],[1,182,"BrowserSearch",120,"BrowserSearch",170,"VK_BROWSER_SEARCH",e,e],[1,183,"BrowserHome",121,"BrowserHome",172,"VK_BROWSER_HOME",e,e],[1,184,"BrowserBack",122,"BrowserBack",166,"VK_BROWSER_BACK",e,e],[1,185,"BrowserForward",123,"BrowserForward",167,"VK_BROWSER_FORWARD",e,e],[1,186,"BrowserStop",0,e,0,"VK_BROWSER_STOP",e,e],[1,187,"BrowserRefresh",0,e,0,"VK_BROWSER_REFRESH",e,e],[1,188,"BrowserFavorites",0,e,0,"VK_BROWSER_FAVORITES",e,e],[1,189,"ZoomToggle",0,e,0,e,e,e],[1,190,"MailReply",0,e,0,e,e,e],[1,191,"MailForward",0,e,0,e,e,e],[1,192,"MailSend",0,e,0,e,e,e],[1,0,e,114,"KeyInComposition",229,e,e,e],[1,0,e,116,"ABNT_C2",194,"VK_ABNT_C2",e,e],[1,0,e,96,"OEM_8",223,"VK_OEM_8",e,e],[1,0,e,0,e,0,"VK_KANA",e,e],[1,0,e,0,e,0,"VK_HANGUL",e,e],[1,0,e,0,e,0,"VK_JUNJA",e,e],[1,0,e,0,e,0,"VK_FINAL",e,e],[1,0,e,0,e,0,"VK_HANJA",e,e],[1,0,e,0,e,0,"VK_KANJI",e,e],[1,0,e,0,e,0,"VK_CONVERT",e,e],[1,0,e,0,e,0,"VK_NONCONVERT",e,e],[1,0,e,0,e,0,"VK_ACCEPT",e,e],[1,0,e,0,e,0,"VK_MODECHANGE",e,e],[1,0,e,0,e,0,"VK_SELECT",e,e],[1,0,e,0,e,0,"VK_PRINT",e,e],[1,0,e,0,e,0,"VK_EXECUTE",e,e],[1,0,e,0,e,0,"VK_SNAPSHOT",e,e],[1,0,e,0,e,0,"VK_HELP",e,e],[1,0,e,0,e,0,"VK_APPS",e,e],[1,0,e,0,e,0,"VK_PROCESSKEY",e,e],[1,0,e,0,e,0,"VK_PACKET",e,e],[1,0,e,0,e,0,"VK_DBE_SBCSCHAR",e,e],[1,0,e,0,e,0,"VK_DBE_DBCSCHAR",e,e],[1,0,e,0,e,0,"VK_ATTN",e,e],[1,0,e,0,e,0,"VK_CRSEL",e,e],[1,0,e,0,e,0,"VK_EXSEL",e,e],[1,0,e,0,e,0,"VK_EREOF",e,e],[1,0,e,0,e,0,"VK_PLAY",e,e],[1,0,e,0,e,0,"VK_ZOOM",e,e],[1,0,e,0,e,0,"VK_NONAME",e,e],[1,0,e,0,e,0,"VK_PA1",e,e],[1,0,e,0,e,0,"VK_OEM_CLEAR",e,e]],i=[],s=[];for(const p of t){const[e,t,m,f,_,v,C,b,E]=p;if(s[t]||(s[t]=!0,c[t]=m,h[m]=t,d[m.toLowerCase()]=t,e&&(u[t]=f,0!==f&&3!==f&&5!==f&&4!==f&&6!==f&&57!==f&&(g[f]=t))),!i[f]){if(i[f]=!0,!_)throw new Error(`String representation missing for key code ${f} around scan code ${m}`);n.define(f,_),r.define(f,b||_),o.define(f,E||b||_)}v&&(a[v]=f),C&&(l[C]=f)}g[3]=46}(),function(e){e.toString=function(e){return n.keyCodeToStr(e)},e.fromString=function(e){return n.strToKeyCode(e)},e.toUserSettingsUS=function(e){return r.keyCodeToStr(e)},e.toUserSettingsGeneral=function(e){return o.keyCodeToStr(e)},e.fromUserSettings=function(e){return r.strToKeyCode(e)||o.strToKeyCode(e)},e.toElectronAccelerator=function(e){if(e>=98&&e<=113)return null;switch(e){case 16:return"Up";case 18:return"Down";case 15:return"Left";case 17:return"Right"}return n.keyCodeToStr(e)}}(p||(p={}))},83619:(e,t,i)=>{"use strict";i.d(t,{G$:()=>l,Of:()=>r,r0:()=>o,rr:()=>a});var s=i(78209);class n{constructor(e,t,i=t){this.modifierLabels=[null],this.modifierLabels[2]=e,this.modifierLabels[1]=t,this.modifierLabels[3]=i}toLabel(e,t,i){if(0===t.length)return null;const s=[];for(let n=0,r=t.length;n{"use strict";i.d(t,{FW:()=>l,Zv:()=>n,dG:()=>o,z5:()=>c});var s=i(64383);function n(e,t){if("number"===typeof e){if(0===e)return null;const i=(65535&e)>>>0,s=(4294901760&e)>>>16;return new a(0!==s?[r(i,t),r(s,t)]:[r(i,t)])}{const i=[];for(let s=0;s{"use strict";i.d(t,{d:()=>s});class s{constructor(e){this.executor=e,this._didRun=!1}get value(){if(!this._didRun)try{this._value=this.executor()}catch(e){this._error=e}finally{this._didRun=!0}if(this._error)throw this._error;return this._value}get rawValue(){return this._value}}},5662:(e,t,i)=>{"use strict";i.d(t,{$w:()=>C,AS:()=>d,Ay:()=>o,BO:()=>v,Cm:()=>p,HE:()=>f,VD:()=>a,Xm:()=>h,jG:()=>m,lC:()=>c,mp:()=>_,qE:()=>u,s:()=>g});var s=i(6921),n=i(42522);let r=null;function o(e){return r?.trackDisposable(e),e}function a(e){r?.markAsDisposed(e)}function l(e,t){r?.setParent(e,t)}function c(e){return r?.markAsSingleton(e),e}function h(e){return"object"===typeof e&&null!==e&&"function"===typeof e.dispose&&0===e.dispose.length}function d(e){if(n.f.is(e)){const i=[];for(const s of e)if(s)try{s.dispose()}catch(t){i.push(t)}if(1===i.length)throw i[0];if(i.length>1)throw new AggregateError(i,"Encountered errors while disposing of store");return Array.isArray(e)?[]:e}if(e)return e.dispose(),e}function u(...e){const t=g((()=>d(e)));return function(e,t){if(r)for(const i of e)r.setParent(i,t)}(e,t),t}function g(e){const t=o({dispose:(0,s.P)((()=>{a(t),e()}))});return t}class p{static{this.DISABLE_DISPOSED_WARNING=!1}constructor(){this._toDispose=new Set,this._isDisposed=!1,o(this)}dispose(){this._isDisposed||(a(this),this._isDisposed=!0,this.clear())}get isDisposed(){return this._isDisposed}clear(){if(0!==this._toDispose.size)try{d(this._toDispose)}finally{this._toDispose.clear()}}add(e){if(!e)return e;if(e===this)throw new Error("Cannot register a disposable on itself!");return l(e,this),this._isDisposed?p.DISABLE_DISPOSED_WARNING||console.warn(new Error("Trying to add a disposable to a DisposableStore that has already been disposed of. The added object will be leaked!").stack):this._toDispose.add(e),e}deleteAndLeak(e){e&&this._toDispose.has(e)&&(this._toDispose.delete(e),l(e,null))}}class m{static{this.None=Object.freeze({dispose(){}})}constructor(){this._store=new p,o(this),l(this._store,this)}dispose(){a(this),this._store.dispose()}_register(e){if(e===this)throw new Error("Cannot register a disposable on itself!");return this._store.add(e)}}class f{constructor(){this._isDisposed=!1,o(this)}get value(){return this._isDisposed?void 0:this._value}set value(e){this._isDisposed||e===this._value||(this._value?.dispose(),e&&l(e,this),this._value=e)}clear(){this.value=void 0}dispose(){this._isDisposed=!0,a(this),this._value?.dispose(),this._value=void 0}}class _{constructor(e){this._disposable=e,this._counter=1}acquire(){return this._counter++,this}release(){return 0===--this._counter&&this._disposable.dispose(),this}}class v{constructor(e){this.object=e}dispose(){}}class C{constructor(){this._store=new Map,this._isDisposed=!1,o(this)}dispose(){a(this),this._isDisposed=!0,this.clearAndDisposeAll()}clearAndDisposeAll(){if(this._store.size)try{d(this._store.values())}finally{this._store.clear()}}get(e){return this._store.get(e)}set(e,t,i=!1){this._isDisposed&&console.warn(new Error("Trying to add a disposable to a DisposableMap that has already been disposed of. The added object will be leaked!").stack),i||this._store.get(e)?.dispose(),this._store.set(e,t)}deleteAndDispose(e){this._store.get(e)?.dispose(),this._store.delete(e)}[Symbol.iterator](){return this._store[Symbol.iterator]()}}},58925:(e,t,i)=>{"use strict";i.d(t,{w:()=>n});class s{static{this.Undefined=new s(void 0)}constructor(e){this.element=e,this.next=s.Undefined,this.prev=s.Undefined}}class n{constructor(){this._first=s.Undefined,this._last=s.Undefined,this._size=0}get size(){return this._size}isEmpty(){return this._first===s.Undefined}clear(){let e=this._first;for(;e!==s.Undefined;){const t=e.next;e.prev=s.Undefined,e.next=s.Undefined,e=t}this._first=s.Undefined,this._last=s.Undefined,this._size=0}unshift(e){return this._insert(e,!1)}push(e){return this._insert(e,!0)}_insert(e,t){const i=new s(e);if(this._first===s.Undefined)this._first=i,this._last=i;else if(t){const e=this._last;this._last=i,i.prev=e,e.next=i}else{const e=this._first;this._first=i,i.next=e,e.prev=i}this._size+=1;let n=!1;return()=>{n||(n=!0,this._remove(i))}}shift(){if(this._first!==s.Undefined){const e=this._first.element;return this._remove(this._first),e}}pop(){if(this._last!==s.Undefined){const e=this._last.element;return this._remove(this._last),e}}_remove(e){if(e.prev!==s.Undefined&&e.next!==s.Undefined){const t=e.prev;t.next=e.next,e.next.prev=t}else e.prev===s.Undefined&&e.next===s.Undefined?(this._first=s.Undefined,this._last=s.Undefined):e.next===s.Undefined?(this._last=this._last.prev,this._last.next=s.Undefined):e.prev===s.Undefined&&(this._first=this._first.next,this._first.prev=s.Undefined);this._size-=1}*[Symbol.iterator](){let e=this._first;for(;e!==s.Undefined;)yield e.element,e=e.next}}},74320:(e,t,i)=>{"use strict";var s,n;i.d(t,{cO:()=>h,db:()=>d,fT:()=>o,qK:()=>c});class r{constructor(e,t){this.uri=e,this.value=t}}class o{static{this.defaultToKey=e=>e.toString()}constructor(e,t){if(this[s]="ResourceMap",e instanceof o)this.map=new Map(e.map),this.toKey=t??o.defaultToKey;else if(function(e){return Array.isArray(e)}(e)){this.map=new Map,this.toKey=t??o.defaultToKey;for(const[t,i]of e)this.set(t,i)}else this.map=new Map,this.toKey=e??o.defaultToKey}set(e,t){return this.map.set(this.toKey(e),new r(e,t)),this}get(e){return this.map.get(this.toKey(e))?.value}has(e){return this.map.has(this.toKey(e))}get size(){return this.map.size}clear(){this.map.clear()}delete(e){return this.map.delete(this.toKey(e))}forEach(e,t){"undefined"!==typeof t&&(e=e.bind(t));for(const[i,s]of this.map)e(s.value,s.uri,this)}*values(){for(const e of this.map.values())yield e.value}*keys(){for(const e of this.map.values())yield e.uri}*entries(){for(const e of this.map.values())yield[e.uri,e.value]}*[(s=Symbol.toStringTag,Symbol.iterator)](){for(const[,e]of this.map)yield[e.uri,e.value]}}class a{constructor(){this[n]="LinkedMap",this._map=new Map,this._head=void 0,this._tail=void 0,this._size=0,this._state=0}clear(){this._map.clear(),this._head=void 0,this._tail=void 0,this._size=0,this._state++}isEmpty(){return!this._head&&!this._tail}get size(){return this._size}get first(){return this._head?.value}get last(){return this._tail?.value}has(e){return this._map.has(e)}get(e,t=0){const i=this._map.get(e);if(i)return 0!==t&&this.touch(i,t),i.value}set(e,t,i=0){let s=this._map.get(e);if(s)s.value=t,0!==i&&this.touch(s,i);else{switch(s={key:e,value:t,next:void 0,previous:void 0},i){case 0:case 2:default:this.addItemLast(s);break;case 1:this.addItemFirst(s)}this._map.set(e,s),this._size++}return this}delete(e){return!!this.remove(e)}remove(e){const t=this._map.get(e);if(t)return this._map.delete(e),this.removeItem(t),this._size--,t.value}shift(){if(!this._head&&!this._tail)return;if(!this._head||!this._tail)throw new Error("Invalid list");const e=this._head;return this._map.delete(e.key),this.removeItem(e),this._size--,e.value}forEach(e,t){const i=this._state;let s=this._head;for(;s;){if(t?e.bind(t)(s.value,s.key,this):e(s.value,s.key,this),this._state!==i)throw new Error("LinkedMap got modified during iteration.");s=s.next}}keys(){const e=this,t=this._state;let i=this._head;const s={[Symbol.iterator]:()=>s,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(i){const e={value:i.key,done:!1};return i=i.next,e}return{value:void 0,done:!0}}};return s}values(){const e=this,t=this._state;let i=this._head;const s={[Symbol.iterator]:()=>s,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(i){const e={value:i.value,done:!1};return i=i.next,e}return{value:void 0,done:!0}}};return s}entries(){const e=this,t=this._state;let i=this._head;const s={[Symbol.iterator]:()=>s,next(){if(e._state!==t)throw new Error("LinkedMap got modified during iteration.");if(i){const e={value:[i.key,i.value],done:!1};return i=i.next,e}return{value:void 0,done:!0}}};return s}[(n=Symbol.toStringTag,Symbol.iterator)](){return this.entries()}trimOld(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._head,i=this.size;for(;t&&i>e;)this._map.delete(t.key),t=t.next,i--;this._head=t,this._size=i,t&&(t.previous=void 0),this._state++}trimNew(e){if(e>=this.size)return;if(0===e)return void this.clear();let t=this._tail,i=this.size;for(;t&&i>e;)this._map.delete(t.key),t=t.previous,i--;this._tail=t,this._size=i,t&&(t.next=void 0),this._state++}addItemFirst(e){if(this._head||this._tail){if(!this._head)throw new Error("Invalid list");e.next=this._head,this._head.previous=e}else this._tail=e;this._head=e,this._state++}addItemLast(e){if(this._head||this._tail){if(!this._tail)throw new Error("Invalid list");e.previous=this._tail,this._tail.next=e}else this._head=e;this._tail=e,this._state++}removeItem(e){if(e===this._head&&e===this._tail)this._head=void 0,this._tail=void 0;else if(e===this._head){if(!e.next)throw new Error("Invalid list");e.next.previous=void 0,this._head=e.next}else if(e===this._tail){if(!e.previous)throw new Error("Invalid list");e.previous.next=void 0,this._tail=e.previous}else{const t=e.next,i=e.previous;if(!t||!i)throw new Error("Invalid list");t.previous=i,i.next=t}e.next=void 0,e.previous=void 0,this._state++}touch(e,t){if(!this._head||!this._tail)throw new Error("Invalid list");if(1===t||2===t)if(1===t){if(e===this._head)return;const t=e.next,i=e.previous;e===this._tail?(i.next=void 0,this._tail=i):(t.previous=i,i.next=t),e.previous=void 0,e.next=this._head,this._head.previous=e,this._head=e,this._state++}else if(2===t){if(e===this._tail)return;const t=e.next,i=e.previous;e===this._head?(t.previous=void 0,this._head=t):(t.previous=i,i.next=t),e.next=void 0,e.previous=this._tail,this._tail.next=e,this._tail=e,this._state++}}toJSON(){const e=[];return this.forEach(((t,i)=>{e.push([i,t])})),e}fromJSON(e){this.clear();for(const[t,i]of e)this.set(t,i)}}class l extends a{constructor(e,t=1){super(),this._limit=e,this._ratio=Math.min(Math.max(0,t),1)}get limit(){return this._limit}set limit(e){this._limit=e,this.checkTrim()}get(e,t=2){return super.get(e,t)}peek(e){return super.get(e,0)}set(e,t){return super.set(e,t,2),this}checkTrim(){this.size>this._limit&&this.trim(Math.round(this._limit*this._ratio))}}class c extends l{constructor(e,t=1){super(e,t)}trim(e){this.trimOld(e)}set(e,t){return super.set(e,t),this.checkTrim(),this}}class h{constructor(e){if(this._m1=new Map,this._m2=new Map,e)for(const[t,i]of e)this.set(t,i)}clear(){this._m1.clear(),this._m2.clear()}set(e,t){this._m1.set(e,t),this._m2.set(t,e)}get(e){return this._m1.get(e)}getKey(e){return this._m2.get(e)}delete(e){const t=this._m1.get(e);return void 0!==t&&(this._m1.delete(e),this._m2.delete(t),!0)}keys(){return this._m1.keys()}values(){return this._m1.values()}}class d{constructor(){this.map=new Map}add(e,t){let i=this.map.get(e);i||(i=new Set,this.map.set(e,i)),i.add(t)}delete(e,t){const i=this.map.get(e);i&&(i.delete(t),0===i.size&&this.map.delete(e))}forEach(e,t){const i=this.map.get(e);i&&i.forEach(t)}get(e){const t=this.map.get(e);return t||new Set}}},908:(e,t,i)=>{"use strict";i.d(t,{As:()=>r,qg:()=>o});var s=i(81674),n=i(79400);function r(e){return JSON.stringify(e,a)}function o(e){let t=JSON.parse(e);return t=l(t),t}function a(e,t){return t instanceof RegExp?{$mid:2,source:t.source,flags:t.flags}:t}function l(e,t=0){if(!e||t>200)return e;if("object"===typeof e){switch(e.$mid){case 1:return n.r.revive(e);case 2:return new RegExp(e.source,e.flags);case 17:return new Date(e.source)}if(e instanceof s.MB||e instanceof Uint8Array)return e;if(Array.isArray(e))for(let i=0;i{"use strict";i.d(t,{K:()=>s});const s=Object.freeze({text:"text/plain",binary:"application/octet-stream",unknown:"application/unknown",markdown:"text/markdown",latex:"text/latex",uriList:"text/uri-list"})},36456:(e,t,i)=>{"use strict";i.d(t,{Ez:()=>d,SJ:()=>p,fV:()=>h,ny:()=>s,v$:()=>c,zl:()=>g});var s,n=i(64383),r=i(98067),o=i(91508),a=i(79400),l=i(74027);function c(e,t){return a.r.isUri(e)?(0,o.Q_)(e.scheme,t):(0,o.ns)(e,t+":")}function h(e,...t){return t.some((t=>c(e,t)))}!function(e){e.inMemory="inmemory",e.vscode="vscode",e.internal="private",e.walkThrough="walkThrough",e.walkThroughSnippet="walkThroughSnippet",e.http="http",e.https="https",e.file="file",e.mailto="mailto",e.untitled="untitled",e.data="data",e.command="command",e.vscodeRemote="vscode-remote",e.vscodeRemoteResource="vscode-remote-resource",e.vscodeManagedRemoteResource="vscode-managed-remote-resource",e.vscodeUserData="vscode-userdata",e.vscodeCustomEditor="vscode-custom-editor",e.vscodeNotebookCell="vscode-notebook-cell",e.vscodeNotebookCellMetadata="vscode-notebook-cell-metadata",e.vscodeNotebookCellMetadataDiff="vscode-notebook-cell-metadata-diff",e.vscodeNotebookCellOutput="vscode-notebook-cell-output",e.vscodeNotebookCellOutputDiff="vscode-notebook-cell-output-diff",e.vscodeNotebookMetadata="vscode-notebook-metadata",e.vscodeInteractiveInput="vscode-interactive-input",e.vscodeSettings="vscode-settings",e.vscodeWorkspaceTrust="vscode-workspace-trust",e.vscodeTerminal="vscode-terminal",e.vscodeChatCodeBlock="vscode-chat-code-block",e.vscodeChatCodeCompareBlock="vscode-chat-code-compare-block",e.vscodeChatSesssion="vscode-chat-editor",e.webviewPanel="webview-panel",e.vscodeWebview="vscode-webview",e.extension="extension",e.vscodeFileResource="vscode-file",e.tmp="tmp",e.vsls="vsls",e.vscodeSourceControl="vscode-scm",e.commentsInput="comment",e.codeSetting="code-setting",e.outputChannel="output"}(s||(s={}));const d=new class{constructor(){this._hosts=Object.create(null),this._ports=Object.create(null),this._connectionTokens=Object.create(null),this._preferredWebSchema="http",this._delegate=null,this._serverRootPath="/"}setPreferredWebSchema(e){this._preferredWebSchema=e}get _remoteResourcesPath(){return l.SA.join(this._serverRootPath,s.vscodeRemoteResource)}rewrite(e){if(this._delegate)try{return this._delegate(e)}catch(h){return n.dz(h),e}const t=e.authority;let i=this._hosts[t];i&&-1!==i.indexOf(":")&&-1===i.indexOf("[")&&(i=`[${i}]`);const o=this._ports[t],l=this._connectionTokens[t];let c=`path=${encodeURIComponent(e.path)}`;return"string"===typeof l&&(c+=`&tkn=${encodeURIComponent(l)}`),a.r.from({scheme:r.HZ?this._preferredWebSchema:s.vscodeRemoteResource,authority:`${i}:${o}`,path:this._remoteResourcesPath,query:c})}};class u{static{this.FALLBACK_AUTHORITY="vscode-app"}asBrowserUri(e){const t=this.toUri(e);return this.uriToBrowserUri(t)}uriToBrowserUri(e){return e.scheme===s.vscodeRemote?d.rewrite(e):e.scheme!==s.file||!r.ib&&r.lg!==`${s.vscodeFileResource}://${u.FALLBACK_AUTHORITY}`?e:e.with({scheme:s.vscodeFileResource,authority:e.authority||u.FALLBACK_AUTHORITY,query:null,fragment:null})}toUri(e,t){if(a.r.isUri(e))return e;if(globalThis._VSCODE_FILE_ROOT){const t=globalThis._VSCODE_FILE_ROOT;if(/^\w[\w\d+.-]*:\/\//.test(t))return a.r.joinPath(a.r.parse(t,!0),e);const i=l.fj(t,e);return a.r.file(i)}return a.r.parse(t.toUrl(e))}}const g=new u;var p;!function(e){const t=new Map([["1",{"Cross-Origin-Opener-Policy":"same-origin"}],["2",{"Cross-Origin-Embedder-Policy":"require-corp"}],["3",{"Cross-Origin-Opener-Policy":"same-origin","Cross-Origin-Embedder-Policy":"require-corp"}]]);e.CoopAndCoep=Object.freeze(t.get("3"));const i="vscode-coi";e.getHeadersFromQuery=function(e){let s;"string"===typeof e?s=new URL(e).searchParams:e instanceof URL?s=e.searchParams:a.r.isUri(e)&&(s=new URL(e.toString(!0)).searchParams);const n=s?.get(i);if(n)return t.get(n)},e.addSearchParam=function(e,t,s){if(!globalThis.crossOriginIsolated)return;const n=t&&s?"3":s?"2":"1";e instanceof URLSearchParams?e.set(i,n):e[i]=n}}(p||(p={}))},1592:(e,t,i)=>{"use strict";function s(e,t,i){return Math.min(Math.max(e,t),i)}i.d(t,{Uq:()=>n,mu:()=>r,qE:()=>s});class n{constructor(){this._n=1,this._val=0}update(e){return this._val=this._val+(e-this._val)/this._n,this._n+=1,this._val}get value(){return this._val}}class r{constructor(e){this._n=0,this._val=0,this._values=[],this._index=0,this._sum=0,this._values=new Array(e),this._values.fill(0,0,e)}update(e){const t=this._values[this._index];return this._values[this._index]=e,this._index=(this._index+1)%this._values.length,this._sum-=t,this._sum+=e,this._n{"use strict";i.d(t,{Go:()=>n,PI:()=>a,V0:()=>d,aI:()=>h,co:()=>c,kT:()=>u,ol:()=>r});var s=i(631);function n(e){if(!e||"object"!==typeof e)return e;if(e instanceof RegExp)return e;const t=Array.isArray(e)?[]:{};return Object.entries(e).forEach((([e,i])=>{t[e]=i&&"object"===typeof i?n(i):i})),t}function r(e){if(!e||"object"!==typeof e)return e;const t=[e];for(;t.length>0;){const e=t.shift();Object.freeze(e);for(const i in e)if(o.call(e,i)){const n=e[i];"object"!==typeof n||Object.isFrozen(n)||(0,s.iu)(n)||t.push(n)}}return e}const o=Object.prototype.hasOwnProperty;function a(e,t){return l(e,t,new Set)}function l(e,t,i){if((0,s.z)(e))return e;const n=t(e);if("undefined"!==typeof n)return n;if(Array.isArray(e)){const s=[];for(const n of e)s.push(l(n,t,i));return s}if((0,s.Gv)(e)){if(i.has(e))throw new Error("Cannot clone recursive data-structure");i.add(e);const s={};for(const n in e)o.call(e,n)&&(s[n]=l(e[n],t,i));return i.delete(e),s}return e}function c(e,t,i=!0){return(0,s.Gv)(e)?((0,s.Gv)(t)&&Object.keys(t).forEach((n=>{n in e?i&&((0,s.Gv)(e[n])&&(0,s.Gv)(t[n])?c(e[n],t[n],i):e[n]=t[n]):e[n]=t[n]})),e):t}function h(e,t){if(e===t)return!0;if(null===e||void 0===e||null===t||void 0===t)return!1;if(typeof e!==typeof t)return!1;if("object"!==typeof e)return!1;if(Array.isArray(e)!==Array.isArray(t))return!1;let i,s;if(Array.isArray(e)){if(e.length!==t.length)return!1;for(i=0;ifunction(){const i=Array.prototype.slice.call(arguments,0);return t(e,i)},s={};for(const n of e)s[n]=i(n);return s}},31308:(e,t,i)=>{"use strict";i.d(t,{BK:()=>_,fm:()=>c,Y:()=>d,zL:()=>h,yC:()=>g,ht:()=>u,lk:()=>m.lk,un:()=>n.un,nb:()=>n.nb,ZX:()=>m.ZX,C:()=>n.C,rm:()=>n.rm,X2:()=>s.X2,y0:()=>m.y0,Yd:()=>m.Yd,yQ:()=>m.yQ,FY:()=>s.FY,Zh:()=>S,OI:()=>m.OI,PO:()=>s.PO,Rn:()=>s.Rn,oJ:()=>C});var s=i(49154),n=i(87958),r=i(66782),o=i(5662),a=i(22311),l=i(94958);function c(e){return new p(new a.nA(void 0,void 0,e),e,void 0,void 0)}function h(e,t){return new p(new a.nA(e.owner,e.debugName,e.debugReferenceFn??t),t,void 0,void 0)}function d(e,t){return new p(new a.nA(e.owner,e.debugName,e.debugReferenceFn??t),t,e.createEmptyChangeSummary,e.handleChange)}function u(e,t){const i=new o.Cm,s=d({owner:e.owner,debugName:e.debugName,debugReferenceFn:e.debugReferenceFn??t,createEmptyChangeSummary:e.createEmptyChangeSummary,handleChange:e.handleChange},((e,s)=>{i.clear(),t(e,s,i)}));return(0,o.s)((()=>{s.dispose(),i.dispose()}))}function g(e){const t=new o.Cm,i=h({owner:void 0,debugName:void 0,debugReferenceFn:e},(i=>{t.clear(),e(i,t)}));return(0,o.s)((()=>{i.dispose(),t.dispose()}))}class p{get debugName(){return this._debugNameData.getDebugName(this)??"(anonymous)"}constructor(e,t,i,s){this._debugNameData=e,this._runFn=t,this.createChangeSummary=i,this._handleChange=s,this.state=2,this.updateCount=0,this.disposed=!1,this.dependencies=new Set,this.dependenciesToBeRemoved=new Set,this.changeSummary=this.createChangeSummary?.(),(0,l.tZ)()?.handleAutorunCreated(this),this._runIfNeeded(),(0,o.Ay)(this)}dispose(){this.disposed=!0;for(const e of this.dependencies)e.removeObserver(this);this.dependencies.clear(),(0,o.VD)(this)}_runIfNeeded(){if(3===this.state)return;const e=this.dependenciesToBeRemoved;this.dependenciesToBeRemoved=this.dependencies,this.dependencies=e,this.state=3;const t=this.disposed;try{if(!t){(0,l.tZ)()?.handleAutorunTriggered(this);const e=this.changeSummary;this.changeSummary=this.createChangeSummary?.(),this._runFn(this,e)}}finally{t||(0,l.tZ)()?.handleAutorunFinished(this);for(const e of this.dependenciesToBeRemoved)e.removeObserver(this);this.dependenciesToBeRemoved.clear()}}toString(){return`Autorun<${this.debugName}>`}beginUpdate(){3===this.state&&(this.state=1),this.updateCount++}endUpdate(){if(1===this.updateCount)do{if(1===this.state){this.state=3;for(const e of this.dependencies)if(e.reportChanges(),2===this.state)break}this._runIfNeeded()}while(3!==this.state);this.updateCount--,(0,r.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)&&(this.state=1)}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){(!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary))&&(this.state=2)}}readObservable(e){if(this.disposed)return e.get();e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}}!function(e){e.Observer=p}(c||(c={}));var m=i(13850),f=i(64383);class _{static fromFn(e){return new _(e())}constructor(e){this._value=(0,s.FY)(this,void 0),this.promiseResult=this._value,this.promise=e.then((e=>((0,s.Rn)((t=>{this._value.set(new v(e,void 0),t)})),e)),(e=>{throw(0,s.Rn)((t=>{this._value.set(new v(void 0,e),t)})),e}))}}class v{constructor(e,t){this.data=e,this.error=t}}function C(e,t,i,s){return t||(t=e=>null!==e&&void 0!==e),new Promise(((n,r)=>{let o=!0,a=!1;const l=e.map((e=>({isFinished:t(e),error:!!i&&i(e),state:e}))),h=c((e=>{const{isFinished:t,error:i,state:s}=l.read(e);(t||i)&&(o?a=!0:h.dispose(),i?r(!0===i?s:i):n(s))}));if(s){const e=s.onCancellationRequested((()=>{h.dispose(),e.dispose(),r(new f.AL)}));if(s.isCancellationRequested)return h.dispose(),e.dispose(),void r(new f.AL)}o=!1,a&&h.dispose()}))}var b=i(51241);class E extends s.ZK{get debugName(){return this._debugNameData.getDebugName(this)??"LazyObservableValue"}constructor(e,t,i){super(),this._debugNameData=e,this._equalityComparator=i,this._isUpToDate=!0,this._deltas=[],this._updateCounter=0,this._value=t}get(){return this._update(),this._value}_update(){if(!this._isUpToDate)if(this._isUpToDate=!0,this._deltas.length>0){for(const e of this.observers)for(const t of this._deltas)e.handleChange(this,t);this._deltas.length=0}else for(const e of this.observers)e.handleChange(this,void 0)}_beginUpdate(){if(this._updateCounter++,1===this._updateCounter)for(const e of this.observers)e.beginUpdate(this)}_endUpdate(){if(this._updateCounter--,0===this._updateCounter){this._update();const e=[...this.observers];for(const t of e)t.endUpdate(this)}}addObserver(e){const t=!this.observers.has(e)&&this._updateCounter>0;super.addObserver(e),t&&e.beginUpdate(this)}removeObserver(e){const t=this.observers.has(e)&&this._updateCounter>0;super.removeObserver(e),t&&e.endUpdate(this)}set(e,t,i){if(void 0===i&&this._equalityComparator(this._value,e))return;let n;t||(t=n=new s.XL((()=>{}),(()=>`Setting ${this.debugName}`)));try{if(this._isUpToDate=!1,this._setValue(e),void 0!==i&&this._deltas.push(i),t.updateObserver({beginUpdate:()=>this._beginUpdate(),endUpdate:()=>this._endUpdate(),handleChange:(e,t)=>{},handlePossibleChange:e=>{}},this),this._updateCounter>1)for(const e of this.observers)e.handlePossibleChange(this)}finally{n&&n.finish()}}toString(){return`${this.debugName}: ${this._value}`}_setValue(e){this._value=e}}function S(e,t){return e.lazy?new E(new a.nA(e.owner,e.debugName,void 0),t,e.equalsFn??b.nx):new s.Lj(new a.nA(e.owner,e.debugName,void 0),t,e.equalsFn??b.nx)}},49154:(e,t,i)=>{"use strict";i.d(t,{Bm:()=>h,FB:()=>d,FY:()=>b,Lj:()=>E,N2:()=>u,PO:()=>v,Rn:()=>m,X2:()=>S,XL:()=>C,YY:()=>f,ZK:()=>p,fL:()=>_,zV:()=>g});var s=i(51241),n=i(22311),r=i(94958);let o,a,l,c;function h(e){o=e}function d(e){a=e}function u(e){l=e}class g{get TChange(){return null}reportChanges(){this.get()}read(e){return e?e.readObservable(this):this.get()}map(e,t){const i=void 0===t?void 0:e,s=void 0===t?e:t;return l({owner:i,debugName:()=>{const e=(0,n.qQ)(s);if(void 0!==e)return e;const t=/^\s*\(?\s*([a-zA-Z_$][a-zA-Z_$0-9]*)\s*\)?\s*=>\s*\1(?:\??)\.([a-zA-Z_$][a-zA-Z_$0-9]*)\s*$/.exec(s.toString());return t?`${this.debugName}.${t[2]}`:i?void 0:`${this.debugName} (mapped)`},debugReferenceFn:s},(e=>s(this.read(e),e)))}flatten(){return l({owner:void 0,debugName:()=>`${this.debugName} (flattened)`},(e=>this.read(e).read(e)))}recomputeInitiallyAndOnChange(e,t){return e.add(o(this,t)),this}keepObserved(e){return e.add(a(this)),this}}class p extends g{constructor(){super(...arguments),this.observers=new Set}addObserver(e){const t=this.observers.size;this.observers.add(e),0===t&&this.onFirstObserverAdded()}removeObserver(e){this.observers.delete(e)&&0===this.observers.size&&this.onLastObserverRemoved()}onFirstObserverAdded(){}onLastObserverRemoved(){}}function m(e,t){const i=new C(e,t);try{e(i)}finally{i.finish()}}function f(e){if(c)e(c);else{const t=new C(e,void 0);c=t;try{e(t)}finally{t.finish(),c=void 0}}}async function _(e,t){const i=new C(e,t);try{await e(i)}finally{i.finish()}}function v(e,t,i){e?t(e):m(t,i)}class C{constructor(e,t){this._fn=e,this._getDebugName=t,this.updatingObservers=[],(0,r.tZ)()?.handleBeginTransaction(this)}getDebugName(){return this._getDebugName?this._getDebugName():(0,n.qQ)(this._fn)}updateObserver(e,t){this.updatingObservers.push({observer:e,observable:t}),e.beginUpdate(t)}finish(){const e=this.updatingObservers;for(let t=0;t{}),(()=>`Setting ${this.debugName}`)));try{const s=this._value;this._setValue(e),(0,r.tZ)()?.handleObservableChanged(this,{oldValue:s,newValue:e,change:i,didChange:!0,hadValue:!0});for(const e of this.observers)t.updateObserver(e,this),e.handleChange(this,i)}finally{s&&s.finish()}}toString(){return`${this.debugName}: ${this._value}`}_setValue(e){this._value=e}}function S(e,t){let i;return i="string"===typeof e?new n.nA(void 0,e,void 0):new n.nA(e,void 0,void 0),new y(i,t,s.nx)}class y extends E{_setValue(e){this._value!==e&&(this._value&&this._value.dispose(),this._value=e)}dispose(){this._value?.dispose()}}},22311:(e,t,i)=>{"use strict";i.d(t,{nA:()=>s,qQ:()=>l});class s{constructor(e,t,i){this.owner=e,this.debugNameSource=t,this.referenceFn=i}getDebugName(e){return function(e,t){const i=r.get(e);if(i)return i;const s=function(e,t){const i=r.get(e);if(i)return i;const s=t.owner?function(e){const t=a.get(e);if(t)return t;const i=function(e){const t=e.constructor;if(t)return t.name;return"Object"}(e);let s=o.get(i)??0;s++,o.set(i,s);const n=1===s?i:`${i}#${s}`;return a.set(e,n),n}(t.owner)+".":"";let n;const c=t.debugNameSource;if(void 0!==c){if("function"!==typeof c)return s+c;if(n=c(),void 0!==n)return s+n}const h=t.referenceFn;if(void 0!==h&&(n=l(h),void 0!==n))return s+n;if(void 0!==t.owner){const i=function(e,t){for(const i in e)if(e[i]===t)return i;return}(t.owner,e);if(void 0!==i)return s+i}return}(e,t);if(s){let t=n.get(s)??0;t++,n.set(s,t);const i=1===t?s:`${s}#${t}`;return r.set(e,i),i}return}(e,this)}}const n=new Map,r=new WeakMap;const o=new Map,a=new WeakMap;function l(e){const t=e.toString(),i=/\/\*\*\s*@description\s*([^*]*)\*\//.exec(t),s=i?i[1]:void 0;return s?.trim()}},87958:(e,t,i)=>{"use strict";i.d(t,{C:()=>d,a0:()=>p,dQ:()=>h,nb:()=>u,rm:()=>g,un:()=>c});var s=i(66782),n=i(51241),r=i(5662),o=i(49154),a=i(22311),l=i(94958);function c(e,t){return void 0!==t?new m(new a.nA(e,void 0,t),t,void 0,void 0,void 0,n.nx):new m(new a.nA(void 0,void 0,e),e,void 0,void 0,void 0,n.nx)}function h(e,t,i){return new f(new a.nA(e,void 0,t),t,void 0,void 0,void 0,n.nx,i)}function d(e,t){return new m(new a.nA(e.owner,e.debugName,e.debugReferenceFn),t,void 0,void 0,e.onLastObserverRemoved,e.equalsFn??n.nx)}function u(e,t){return new m(new a.nA(e.owner,e.debugName,void 0),t,e.createEmptyChangeSummary,e.handleChange,void 0,e.equalityComparer??n.nx)}function g(e,t){let i,s;void 0===t?(i=e,s=void 0):(s=e,i=t);const o=new r.Cm;return new m(new a.nA(s,void 0,i),(e=>(o.clear(),i(e,o))),void 0,void 0,(()=>o.dispose()),n.nx)}function p(e,t){let i,s,o;return void 0===t?(i=e,s=void 0):(s=e,i=t),new m(new a.nA(s,void 0,i),(e=>{o?o.clear():o=new r.Cm;const t=i(e);return t&&o.add(t),t}),void 0,void 0,(()=>{o&&(o.dispose(),o=void 0)}),n.nx)}(0,o.N2)(d);class m extends o.ZK{get debugName(){return this._debugNameData.getDebugName(this)??"(anonymous)"}constructor(e,t,i,s,n=void 0,r){super(),this._debugNameData=e,this._computeFn=t,this.createChangeSummary=i,this._handleChange=s,this._handleLastObserverRemoved=n,this._equalityComparator=r,this.state=0,this.value=void 0,this.updateCount=0,this.dependencies=new Set,this.dependenciesToBeRemoved=new Set,this.changeSummary=void 0,this.changeSummary=this.createChangeSummary?.(),(0,l.tZ)()?.handleDerivedCreated(this)}onLastObserverRemoved(){this.state=0,this.value=void 0;for(const e of this.dependencies)e.removeObserver(this);this.dependencies.clear(),this._handleLastObserverRemoved?.()}get(){if(0===this.observers.size){const e=this._computeFn(this,this.createChangeSummary?.());return this.onLastObserverRemoved(),e}do{if(1===this.state)for(const e of this.dependencies)if(e.reportChanges(),2===this.state)break;1===this.state&&(this.state=3),this._recomputeIfNeeded()}while(3!==this.state);return this.value}_recomputeIfNeeded(){if(3===this.state)return;const e=this.dependenciesToBeRemoved;this.dependenciesToBeRemoved=this.dependencies,this.dependencies=e;const t=0!==this.state,i=this.value;this.state=3;const s=this.changeSummary;this.changeSummary=this.createChangeSummary?.();try{this.value=this._computeFn(this,s)}finally{for(const e of this.dependenciesToBeRemoved)e.removeObserver(this);this.dependenciesToBeRemoved.clear()}const n=t&&!this._equalityComparator(i,this.value);if((0,l.tZ)()?.handleDerivedRecomputed(this,{oldValue:i,newValue:this.value,change:void 0,didChange:n,hadValue:t}),n)for(const r of this.observers)r.handleChange(this,void 0)}toString(){return`LazyDerived<${this.debugName}>`}beginUpdate(e){this.updateCount++;const t=1===this.updateCount;if(3===this.state&&(this.state=1,!t))for(const i of this.observers)i.handlePossibleChange(this);if(t)for(const i of this.observers)i.beginUpdate(this)}endUpdate(e){if(this.updateCount--,0===this.updateCount){const e=[...this.observers];for(const t of e)t.endUpdate(this)}(0,s.Ft)((()=>this.updateCount>=0))}handlePossibleChange(e){if(3===this.state&&this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){this.state=1;for(const e of this.observers)e.handlePossibleChange(this)}}handleChange(e,t){if(this.dependencies.has(e)&&!this.dependenciesToBeRemoved.has(e)){const i=!this._handleChange||this._handleChange({changedObservable:e,change:t,didChange:t=>t===e},this.changeSummary),s=3===this.state;if(i&&(1===this.state||s)&&(this.state=2,s))for(const e of this.observers)e.handlePossibleChange(this)}}readObservable(e){e.addObserver(this);const t=e.get();return this.dependencies.add(e),this.dependenciesToBeRemoved.delete(e),t}addObserver(e){const t=!this.observers.has(e)&&this.updateCount>0;super.addObserver(e),t&&e.beginUpdate(this)}removeObserver(e){const t=this.observers.has(e)&&this.updateCount>0;super.removeObserver(e),t&&e.endUpdate(this)}}class f extends m{constructor(e,t,i,s,n=void 0,r,o){super(e,t,i,s,n,r),this.set=o}}},94958:(e,t,i)=>{"use strict";let s;function n(e){s=e}function r(){return s}i.d(t,{Br:()=>n,jm:()=>o,tZ:()=>r});class o{constructor(){this.indentation=0,this.changedObservablesSets=new WeakMap}textToConsoleArgs(e){return function(e){const t=new Array,i=[];let s="";function n(e){if("length"in e)for(const t of e)t&&n(t);else"text"in e?(s+=`%c${e.text}`,t.push(e.style),e.data&&i.push(...e.data)):"data"in e&&i.push(...e.data)}n(e);const r=[s,...t];return r.push(...i),r}([a(d("| ",this.indentation)),e])}formatInfo(e){return e.hadValue?e.didChange?[a(" "),c(h(e.oldValue,70),{color:"red",strikeThrough:!0}),a(" "),c(h(e.newValue,60),{color:"green"})]:[a(" (unchanged)")]:[a(" "),c(h(e.newValue,60),{color:"green"}),a(" (initial)")]}handleObservableChanged(e,t){console.log(...this.textToConsoleArgs([l("observable value changed"),c(e.debugName,{color:"BlueViolet"}),...this.formatInfo(t)]))}formatChanges(e){if(0!==e.size)return c(" (changed deps: "+[...e].map((e=>e.debugName)).join(", ")+")",{color:"gray"})}handleDerivedCreated(e){const t=e.handleChange;this.changedObservablesSets.set(e,new Set),e.handleChange=(i,s)=>(this.changedObservablesSets.get(e).add(i),t.apply(e,[i,s]))}handleDerivedRecomputed(e,t){const i=this.changedObservablesSets.get(e);console.log(...this.textToConsoleArgs([l("derived recomputed"),c(e.debugName,{color:"BlueViolet"}),...this.formatInfo(t),this.formatChanges(i),{data:[{fn:e._debugNameData.referenceFn??e._computeFn}]}])),i.clear()}handleFromEventObservableTriggered(e,t){console.log(...this.textToConsoleArgs([l("observable from event triggered"),c(e.debugName,{color:"BlueViolet"}),...this.formatInfo(t),{data:[{fn:e._getValue}]}]))}handleAutorunCreated(e){const t=e.handleChange;this.changedObservablesSets.set(e,new Set),e.handleChange=(i,s)=>(this.changedObservablesSets.get(e).add(i),t.apply(e,[i,s]))}handleAutorunTriggered(e){const t=this.changedObservablesSets.get(e);console.log(...this.textToConsoleArgs([l("autorun"),c(e.debugName,{color:"BlueViolet"}),this.formatChanges(t),{data:[{fn:e._debugNameData.referenceFn??e._runFn}]}])),t.clear(),this.indentation++}handleAutorunFinished(e){this.indentation--}handleBeginTransaction(e){let t=e.getDebugName();void 0===t&&(t=""),console.log(...this.textToConsoleArgs([l("transaction"),c(t,{color:"BlueViolet"}),{data:[{fn:e._fn}]}])),this.indentation++}handleEndTransaction(){this.indentation--}}function a(e){return c(e,{color:"black"})}function l(e){return c(function(e,t){for(;e.length`${e}${t}:${i};`),""))};var s}function h(e,t){switch(typeof e){case"number":default:return""+e;case"string":return e.length+2<=t?`"${e}"`:`"${e.substr(0,t-7)}"+...`;case"boolean":return e?"true":"false";case"undefined":return"undefined";case"object":return null===e?"null":Array.isArray(e)?function(e,t){let i="[ ",s=!0;for(const n of e){if(s||(i+=", "),i.length-5>t){i+="...";break}s=!1,i+=`${h(n,t-i.length)}`}return i+=" ]",i}(e,t):function(e,t){let i="{ ",s=!0;for(const[n,r]of Object.entries(e)){if(s||(i+=", "),i.length-5>t){i+="...";break}s=!1,i+=`${n}: ${h(r,t-i.length)}`}return i+=" }",i}(e,t);case"symbol":return e.toString();case"function":return`[[Function${e.name?" "+e.name:""}]]`}}function d(e,t){let i="";for(let s=1;s<=t;s++)i+=e;return i}},13850:(e,t,i)=>{"use strict";i.d(t,{OI:()=>v,Rl:()=>E,Yd:()=>f,ZX:()=>b,eP:()=>u,lk:()=>c,t:()=>y,y0:()=>d,yQ:()=>p});i(41234);var s=i(5662),n=i(49154),r=i(22311),o=i(87958),a=i(94958),l=i(51241);function c(e){return new h(e)}class h extends n.zV{constructor(e){super(),this.value=e}get debugName(){return this.toString()}get(){return this.value}addObserver(e){}removeObserver(e){}toString(){return`Const: ${this.value}`}}function d(...e){let t,i,s;return 3===e.length?[t,i,s]=e:[i,s]=e,new g(new r.nA(t,void 0,s),i,s,(()=>g.globalTransaction),l.nx)}function u(e,t,i){return new g(new r.nA(e.owner,e.debugName,e.debugReferenceFn??i),t,i,(()=>g.globalTransaction),e.equalsFn??l.nx)}class g extends n.ZK{constructor(e,t,i,s,r){super(),this._debugNameData=e,this.event=t,this._getValue=i,this._getTransaction=s,this._equalityComparator=r,this.hasValue=!1,this.handleEvent=e=>{const t=this._getValue(e),i=this.value,s=!this.hasValue||!this._equalityComparator(i,t);let r=!1;s&&(this.value=t,this.hasValue&&(r=!0,(0,n.PO)(this._getTransaction(),(e=>{(0,a.tZ)()?.handleFromEventObservableTriggered(this,{oldValue:i,newValue:t,change:void 0,didChange:s,hadValue:this.hasValue});for(const t of this.observers)e.updateObserver(t,this),t.handleChange(this,void 0)}),(()=>{const e=this.getDebugName();return"Event fired"+(e?`: ${e}`:"")}))),this.hasValue=!0),r||(0,a.tZ)()?.handleFromEventObservableTriggered(this,{oldValue:i,newValue:t,change:void 0,didChange:s,hadValue:this.hasValue})}}getDebugName(){return this._debugNameData.getDebugName(this)}get debugName(){const e=this.getDebugName();return"From Event"+(e?`: ${e}`:"")}onFirstObserverAdded(){this.subscription=this.event(this.handleEvent)}onLastObserverRemoved(){this.subscription.dispose(),this.subscription=void 0,this.hasValue=!1,this.value=void 0}get(){if(this.subscription)return this.hasValue||this.handleEvent(void 0),this.value;return this._getValue(void 0)}}function p(e,t){return new m(e,t)}!function(e){e.Observer=g,e.batchEventsGlobally=function(e,t){let i=!1;void 0===g.globalTransaction&&(g.globalTransaction=e,i=!0);try{t()}finally{i&&(g.globalTransaction=void 0)}}}(d||(d={}));class m extends n.ZK{constructor(e,t){super(),this.debugName=e,this.event=t,this.handleEvent=()=>{(0,n.Rn)((e=>{for(const t of this.observers)e.updateObserver(t,this),t.handleChange(this,void 0)}),(()=>this.debugName))}}onFirstObserverAdded(){this.subscription=this.event(this.handleEvent)}onLastObserverRemoved(){this.subscription.dispose(),this.subscription=void 0}get(){}}function f(e){return"string"===typeof e?new _(e):new _(void 0,e)}class _ extends n.ZK{get debugName(){return new r.nA(this._owner,this._debugName,void 0).getDebugName(this)??"Observable Signal"}toString(){return this.debugName}constructor(e,t){super(),this._debugName=e,this._owner=t}trigger(e,t){if(e)for(const i of this.observers)e.updateObserver(i,this),i.handleChange(this,t);else(0,n.Rn)((e=>{this.trigger(e,t)}),(()=>`Trigger signal ${this.debugName}`))}get(){}}function v(e,t){const i=new C(!0,t);return e.addObserver(i),t?t(e.get()):e.reportChanges(),(0,s.s)((()=>{e.removeObserver(i)}))}(0,n.FB)((function(e){const t=new C(!1,void 0);return e.addObserver(t),(0,s.s)((()=>{e.removeObserver(t)}))})),(0,n.Bm)(v);class C{constructor(e,t){this._forceRecompute=e,this._handleValue=t,this._counter=0}beginUpdate(e){this._counter++}endUpdate(e){this._counter--,0===this._counter&&this._forceRecompute&&(this._handleValue?this._handleValue(e.get()):e.reportChanges())}handlePossibleChange(e){}handleChange(e,t){}}function b(e,t){let i;return(0,o.C)({owner:e,debugReferenceFn:t},(e=>(i=t(e,i),i)))}function E(e,t,i,s){let n=new S(i,s);return(0,o.C)({debugReferenceFn:i,owner:e,onLastObserverRemoved:()=>{n.dispose(),n=new S(i)}},(e=>(n.setItems(t.read(e)),n.getItems())))}class S{constructor(e,t){this._map=e,this._keySelector=t,this._cache=new Map,this._items=[]}dispose(){this._cache.forEach((e=>e.store.dispose())),this._cache.clear()}setItems(e){const t=[],i=new Set(this._cache.keys());for(const n of e){const e=this._keySelector?this._keySelector(n):n;let r=this._cache.get(e);if(r)i.delete(e);else{const t=new s.Cm;r={out:this._map(n,t),store:t},this._cache.set(e,r)}t.push(r.out)}for(const s of i){this._cache.get(s).store.dispose(),this._cache.delete(s)}this._items=t}getItems(){return this._items}}function y(e,t){return b(e,((e,i)=>i??t(e)))}},74027:(e,t,i)=>{"use strict";i.d(t,{IN:()=>f,LC:()=>L,P8:()=>w,S8:()=>C,SA:()=>v,V8:()=>S,Vn:()=>R,fj:()=>b,hd:()=>E,pD:()=>y});var s=i(59911);const n=46,r=47,o=92,a=58;class l extends Error{constructor(e,t,i){let s;"string"===typeof t&&0===t.indexOf("not ")?(s="must not be",t=t.replace(/^not /,"")):s="must be";const n=-1!==e.indexOf(".")?"property":"argument";let r=`The "${e}" ${n} ${s} of type ${t}`;r+=". Received type "+typeof i,super(r),this.code="ERR_INVALID_ARG_TYPE"}}function c(e,t){if("string"!==typeof e)throw new l(t,"string",e)}const h="win32"===s.iD;function d(e){return e===r||e===o}function u(e){return e===r}function g(e){return e>=65&&e<=90||e>=97&&e<=122}function p(e,t,i,s){let o="",a=0,l=-1,c=0,h=0;for(let d=0;d<=e.length;++d){if(d2){const e=o.lastIndexOf(i);-1===e?(o="",a=0):(o=o.slice(0,e),a=o.length-1-o.lastIndexOf(i)),l=d,c=0;continue}if(0!==o.length){o="",a=0,l=d,c=0;continue}}t&&(o+=o.length>0?`${i}..`:"..",a=2)}else o.length>0?o+=`${i}${e.slice(l+1,d)}`:o=e.slice(l+1,d),a=d-l-1;l=d,c=0}else h===n&&-1!==c?++c:c=-1}return o}function m(e,t){!function(e,t){if(null===e||"object"!==typeof e)throw new l(t,"Object",e)}(t,"pathObject");const i=t.dir||t.root,s=t.base||`${t.name||""}${n=t.ext,n?`${"."===n[0]?"":"."}${n}`:""}`;var n;return i?i===t.root?`${i}${s}`:`${i}${e}${s}`:s}const f={resolve(...e){let t="",i="",n=!1;for(let r=e.length-1;r>=-1;r--){let l;if(r>=0){if(l=e[r],c(l,`paths[${r}]`),0===l.length)continue}else 0===t.length?l=s.bJ():(l={NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}[`=${t}`]||s.bJ(),(void 0===l||l.slice(0,2).toLowerCase()!==t.toLowerCase()&&l.charCodeAt(2)===o)&&(l=`${t}\\`));const h=l.length;let u=0,p="",m=!1;const f=l.charCodeAt(0);if(1===h)d(f)&&(u=1,m=!0);else if(d(f))if(m=!0,d(l.charCodeAt(1))){let e=2,t=e;for(;e2&&d(l.charCodeAt(2))&&(m=!0,u=3));if(p.length>0)if(t.length>0){if(p.toLowerCase()!==t.toLowerCase())continue}else t=p;if(n){if(t.length>0)break}else if(i=`${l.slice(u)}\\${i}`,n=m,m&&t.length>0)break}return i=p(i,!n,"\\",d),n?`${t}\\${i}`:`${t}${i}`||"."},normalize(e){c(e,"path");const t=e.length;if(0===t)return".";let i,s=0,n=!1;const r=e.charCodeAt(0);if(1===t)return u(r)?"\\":e;if(d(r))if(n=!0,d(e.charCodeAt(1))){let n=2,r=n;for(;n2&&d(e.charCodeAt(2))&&(n=!0,s=3));let o=s0&&d(e.charCodeAt(t-1))&&(o+="\\"),void 0===i?n?`\\${o}`:o:n?`${i}\\${o}`:`${i}${o}`},isAbsolute(e){c(e,"path");const t=e.length;if(0===t)return!1;const i=e.charCodeAt(0);return d(i)||t>2&&g(i)&&e.charCodeAt(1)===a&&d(e.charCodeAt(2))},join(...e){if(0===e.length)return".";let t,i;for(let r=0;r0&&(void 0===t?t=i=s:t+=`\\${s}`)}if(void 0===t)return".";let s=!0,n=0;if("string"===typeof i&&d(i.charCodeAt(0))){++n;const e=i.length;e>1&&d(i.charCodeAt(1))&&(++n,e>2&&(d(i.charCodeAt(2))?++n:s=!1))}if(s){for(;n=2&&(t=`\\${t.slice(n)}`)}return f.normalize(t)},relative(e,t){if(c(e,"from"),c(t,"to"),e===t)return"";const i=f.resolve(e),s=f.resolve(t);if(i===s)return"";if((e=i.toLowerCase())===(t=s.toLowerCase()))return"";let n=0;for(;nn&&e.charCodeAt(r-1)===o;)r--;const a=r-n;let l=0;for(;ll&&t.charCodeAt(h-1)===o;)h--;const d=h-l,u=au){if(t.charCodeAt(l+p)===o)return s.slice(l+p+1);if(2===p)return s.slice(l+p)}a>u&&(e.charCodeAt(n+p)===o?g=p:2===p&&(g=3)),-1===g&&(g=0)}let m="";for(p=n+g+1;p<=r;++p)p!==r&&e.charCodeAt(p)!==o||(m+=0===m.length?"..":"\\..");return l+=g,m.length>0?`${m}${s.slice(l,h)}`:(s.charCodeAt(l)===o&&++l,s.slice(l,h))},toNamespacedPath(e){if("string"!==typeof e||0===e.length)return e;const t=f.resolve(e);if(t.length<=2)return e;if(t.charCodeAt(0)===o){if(t.charCodeAt(1)===o){const e=t.charCodeAt(2);if(63!==e&&e!==n)return`\\\\?\\UNC\\${t.slice(2)}`}}else if(g(t.charCodeAt(0))&&t.charCodeAt(1)===a&&t.charCodeAt(2)===o)return`\\\\?\\${t}`;return e},dirname(e){c(e,"path");const t=e.length;if(0===t)return".";let i=-1,s=0;const n=e.charCodeAt(0);if(1===t)return d(n)?e:".";if(d(n)){if(i=s=1,d(e.charCodeAt(1))){let n=2,r=n;for(;n2&&d(e.charCodeAt(2))?3:2,s=i);let r=-1,o=!0;for(let a=t-1;a>=s;--a)if(d(e.charCodeAt(a))){if(!o){r=a;break}}else o=!1;if(-1===r){if(-1===i)return".";r=i}return e.slice(0,r)},basename(e,t){void 0!==t&&c(t,"suffix"),c(e,"path");let i,s=0,n=-1,r=!0;if(e.length>=2&&g(e.charCodeAt(0))&&e.charCodeAt(1)===a&&(s=2),void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let o=t.length-1,a=-1;for(i=e.length-1;i>=s;--i){const l=e.charCodeAt(i);if(d(l)){if(!r){s=i+1;break}}else-1===a&&(r=!1,a=i+1),o>=0&&(l===t.charCodeAt(o)?-1===--o&&(n=i):(o=-1,n=a))}return s===n?n=a:-1===n&&(n=e.length),e.slice(s,n)}for(i=e.length-1;i>=s;--i)if(d(e.charCodeAt(i))){if(!r){s=i+1;break}}else-1===n&&(r=!1,n=i+1);return-1===n?"":e.slice(s,n)},extname(e){c(e,"path");let t=0,i=-1,s=0,r=-1,o=!0,l=0;e.length>=2&&e.charCodeAt(1)===a&&g(e.charCodeAt(0))&&(t=s=2);for(let a=e.length-1;a>=t;--a){const t=e.charCodeAt(a);if(d(t)){if(!o){s=a+1;break}}else-1===r&&(o=!1,r=a+1),t===n?-1===i?i=a:1!==l&&(l=1):-1!==i&&(l=-1)}return-1===i||-1===r||0===l||1===l&&i===r-1&&i===s+1?"":e.slice(i,r)},format:m.bind(null,"\\"),parse(e){c(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const i=e.length;let s=0,r=e.charCodeAt(0);if(1===i)return d(r)?(t.root=t.dir=e,t):(t.base=t.name=e,t);if(d(r)){if(s=1,d(e.charCodeAt(1))){let t=2,n=t;for(;t0&&(t.root=e.slice(0,s));let o=-1,l=s,h=-1,u=!0,p=e.length-1,m=0;for(;p>=s;--p)if(r=e.charCodeAt(p),d(r)){if(!u){l=p+1;break}}else-1===h&&(u=!1,h=p+1),r===n?-1===o?o=p:1!==m&&(m=1):-1!==o&&(m=-1);return-1!==h&&(-1===o||0===m||1===m&&o===h-1&&o===l+1?t.base=t.name=e.slice(l,h):(t.name=e.slice(l,o),t.base=e.slice(l,h),t.ext=e.slice(o,h))),t.dir=l>0&&l!==s?e.slice(0,l-1):t.root,t},sep:"\\",delimiter:";",win32:null,posix:null},_=(()=>{if(h){const e=/\\/g;return()=>{const t=s.bJ().replace(e,"/");return t.slice(t.indexOf("/"))}}return()=>s.bJ()})(),v={resolve(...e){let t="",i=!1;for(let s=e.length-1;s>=-1&&!i;s--){const n=s>=0?e[s]:_();c(n,`paths[${s}]`),0!==n.length&&(t=`${n}/${t}`,i=n.charCodeAt(0)===r)}return t=p(t,!i,"/",u),i?`/${t}`:t.length>0?t:"."},normalize(e){if(c(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===r,i=e.charCodeAt(e.length-1)===r;return 0===(e=p(e,!t,"/",u)).length?t?"/":i?"./":".":(i&&(e+="/"),t?`/${e}`:e)},isAbsolute:e=>(c(e,"path"),e.length>0&&e.charCodeAt(0)===r),join(...e){if(0===e.length)return".";let t;for(let i=0;i0&&(void 0===t?t=s:t+=`/${s}`)}return void 0===t?".":v.normalize(t)},relative(e,t){if(c(e,"from"),c(t,"to"),e===t)return"";if((e=v.resolve(e))===(t=v.resolve(t)))return"";const i=e.length,s=i-1,n=t.length-1,o=so){if(t.charCodeAt(1+l)===r)return t.slice(1+l+1);if(0===l)return t.slice(1+l)}else s>o&&(e.charCodeAt(1+l)===r?a=l:0===l&&(a=0));let h="";for(l=1+a+1;l<=i;++l)l!==i&&e.charCodeAt(l)!==r||(h+=0===h.length?"..":"/..");return`${h}${t.slice(1+a)}`},toNamespacedPath:e=>e,dirname(e){if(c(e,"path"),0===e.length)return".";const t=e.charCodeAt(0)===r;let i=-1,s=!0;for(let n=e.length-1;n>=1;--n)if(e.charCodeAt(n)===r){if(!s){i=n;break}}else s=!1;return-1===i?t?"/":".":t&&1===i?"//":e.slice(0,i)},basename(e,t){void 0!==t&&c(t,"ext"),c(e,"path");let i,s=0,n=-1,o=!0;if(void 0!==t&&t.length>0&&t.length<=e.length){if(t===e)return"";let a=t.length-1,l=-1;for(i=e.length-1;i>=0;--i){const c=e.charCodeAt(i);if(c===r){if(!o){s=i+1;break}}else-1===l&&(o=!1,l=i+1),a>=0&&(c===t.charCodeAt(a)?-1===--a&&(n=i):(a=-1,n=l))}return s===n?n=l:-1===n&&(n=e.length),e.slice(s,n)}for(i=e.length-1;i>=0;--i)if(e.charCodeAt(i)===r){if(!o){s=i+1;break}}else-1===n&&(o=!1,n=i+1);return-1===n?"":e.slice(s,n)},extname(e){c(e,"path");let t=-1,i=0,s=-1,o=!0,a=0;for(let l=e.length-1;l>=0;--l){const c=e.charCodeAt(l);if(c!==r)-1===s&&(o=!1,s=l+1),c===n?-1===t?t=l:1!==a&&(a=1):-1!==t&&(a=-1);else if(!o){i=l+1;break}}return-1===t||-1===s||0===a||1===a&&t===s-1&&t===i+1?"":e.slice(t,s)},format:m.bind(null,"/"),parse(e){c(e,"path");const t={root:"",dir:"",base:"",ext:"",name:""};if(0===e.length)return t;const i=e.charCodeAt(0)===r;let s;i?(t.root="/",s=1):s=0;let o=-1,a=0,l=-1,h=!0,d=e.length-1,u=0;for(;d>=s;--d){const t=e.charCodeAt(d);if(t!==r)-1===l&&(h=!1,l=d+1),t===n?-1===o?o=d:1!==u&&(u=1):-1!==o&&(u=-1);else if(!h){a=d+1;break}}if(-1!==l){const s=0===a&&i?1:a;-1===o||0===u||1===u&&o===l-1&&o===a+1?t.base=t.name=e.slice(s,l):(t.name=e.slice(s,o),t.base=e.slice(s,l),t.ext=e.slice(o,l))}return a>0?t.dir=e.slice(0,a-1):i&&(t.dir="/"),t},sep:"/",delimiter:":",win32:null,posix:null};v.win32=f.win32=f,v.posix=f.posix=v;const C=h?f.normalize:v.normalize,b=h?f.join:v.join,E=h?f.resolve:v.resolve,S=h?f.relative:v.relative,y=h?f.dirname:v.dirname,w=h?f.basename:v.basename,L=h?f.extname:v.extname,R=h?f.sep:v.sep},98067:(e,t,i)=>{"use strict";i.d(t,{BH:()=>D,Fr:()=>I,H8:()=>W,HZ:()=>k,OS:()=>F,UP:()=>G,_p:()=>P,cm:()=>B,gm:()=>V,ib:()=>x,j9:()=>T,lg:()=>A,m0:()=>j,nr:()=>z,uF:()=>L,un:()=>N,zx:()=>R});var s=i(78209);const n="en";let r,o,a=!1,l=!1,c=!1,h=!1,d=!1,u=!1,g=!1,p=!1,m=!1,f=!1,_=n,v=null,C=null;const b=globalThis;let E;"undefined"!==typeof b.vscode&&"undefined"!==typeof b.vscode.process?E=b.vscode.process:"undefined"!==typeof process&&"string"===typeof process?.versions?.node&&(E=process);const S="string"===typeof E?.versions?.electron,y=S&&"renderer"===E?.type;if("object"===typeof E){a="win32"===E.platform,l="darwin"===E.platform,c="linux"===E.platform,h=c&&!!E.env.SNAP&&!!E.env.SNAP_REVISION,g=S,m=!!E.env.CI||!!E.env.BUILD_ARTIFACTSTAGINGDIRECTORY,r=n,_=n;const e=E.env.VSCODE_NLS_CONFIG;if(e)try{const t=JSON.parse(e);r=t.userLocale,v=t.osLocale,_=t.resolvedLanguage||n,C=t.languagePack?.translationsConfigFile}catch(K){}d=!0}else"object"!==typeof navigator||y?console.error("Unable to resolve platform."):(o=navigator.userAgent,a=o.indexOf("Windows")>=0,l=o.indexOf("Macintosh")>=0,p=(o.indexOf("Macintosh")>=0||o.indexOf("iPad")>=0||o.indexOf("iPhone")>=0)&&!!navigator.maxTouchPoints&&navigator.maxTouchPoints>0,c=o.indexOf("Linux")>=0,f=o?.indexOf("Mobi")>=0,u=!0,_=s.i8()||n,r=navigator.language.toLowerCase(),v=r);let w=0;l?w=1:a?w=3:c&&(w=2);const L=a,R=l,T=c,x=d,k=u,A=u&&"function"===typeof b.importScripts?b.origin:void 0,N=p,I=f,O=o,D=_,M="function"===typeof b.postMessage&&!b.importScripts,P=(()=>{if(M){const e=[];b.addEventListener("message",(t=>{if(t.data&&t.data.vscodeScheduleAsyncWork)for(let i=0,s=e.length;i{const s=++t;e.push({id:s,callback:i}),b.postMessage({vscodeScheduleAsyncWork:s},"*")}}return e=>setTimeout(e)})(),F=l||p?2:a?1:3;let U=!0,H=!1;function B(){if(!H){H=!0;const e=new Uint8Array(2);e[0]=1,e[1]=2;const t=new Uint16Array(e.buffer);U=513===t[0]}return U}const W=!!(O&&O.indexOf("Chrome")>=0),V=!!(O&&O.indexOf("Firefox")>=0),z=!!(!W&&O&&O.indexOf("Safari")>=0),G=!!(O&&O.indexOf("Edg/")>=0),j=!!(O&&O.indexOf("Android")>=0)},59911:(e,t,i)=>{"use strict";i.d(t,{_K:()=>a,bJ:()=>o,iD:()=>l});var s=i(98067);let n;const r=globalThis.vscode;if("undefined"!==typeof r&&"undefined"!==typeof r.process){const e=r.process;n={get platform(){return e.platform},get arch(){return e.arch},get env(){return e.env},cwd:()=>e.cwd()}}else n="undefined"!==typeof process&&"string"===typeof process?.versions?.node?{get platform(){return process.platform},get arch(){return process.arch},get env(){return{NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}},cwd:()=>({NODE_ENV:"production",PUBLIC_URL:".",WDS_SOCKET_HOST:void 0,WDS_SOCKET_PATH:void 0,WDS_SOCKET_PORT:void 0,FAST_REFRESH:!0,REACT_APP_BACKEND:"http://localhost:8765",REACT_APP_META_BACKEND:"undefined"}.VSCODE_CWD||process.cwd())}:{get platform(){return s.uF?"win32":s.zx?"darwin":"linux"},get arch(){},get env(){return{}},cwd:()=>"/"};const o=n.cwd,a=n.env,l=n.platform},92719:(e,t,i)=>{"use strict";var s;i.d(t,{Q:()=>s}),function(e){function t(e,t){if(e.start>=t.end||t.start>=e.end)return{start:0,end:0};const i=Math.max(e.start,t.start),s=Math.min(e.end,t.end);return s-i<=0?{start:0,end:0}:{start:i,end:s}}function i(e){return e.end-e.start<=0}e.intersect=t,e.isEmpty=i,e.intersects=function(e,s){return!i(t(e,s))},e.relativeComplement=function(e,t){const s=[],n={start:e.start,end:Math.min(t.start,e.end)},r={start:Math.max(t.end,e.start),end:e.end};return i(n)||s.push(n),i(r)||s.push(r),s}}(s||(s={}))},89403:(e,t,i)=>{"use strict";i.d(t,{B6:()=>y,Fd:()=>v,LC:()=>m,P8:()=>p,Pi:()=>g,er:()=>d,iZ:()=>C,n4:()=>u,o1:()=>b,pD:()=>f,su:()=>c,uJ:()=>_});var s=i(79326),n=i(36456),r=i(74027),o=i(98067),a=i(91508),l=i(79400);function c(e){return(0,l.I)(e,!0)}class h{constructor(e){this._ignorePathCasing=e}compare(e,t,i=!1){return e===t?0:(0,a.UD)(this.getComparisonKey(e,i),this.getComparisonKey(t,i))}isEqual(e,t,i=!1){return e===t||!(!e||!t)&&this.getComparisonKey(e,i)===this.getComparisonKey(t,i)}getComparisonKey(e,t=!1){return e.with({path:this._ignorePathCasing(e)?e.path.toLowerCase():void 0,fragment:t?null:void 0}).toString()}isEqualOrParent(e,t,i=!1){if(e.scheme===t.scheme){if(e.scheme===n.ny.file)return s._1(c(e),c(t),this._ignorePathCasing(e))&&e.query===t.query&&(i||e.fragment===t.fragment);if(E(e.authority,t.authority))return s._1(e.path,t.path,this._ignorePathCasing(e),"/")&&e.query===t.query&&(i||e.fragment===t.fragment)}return!1}joinPath(e,...t){return l.r.joinPath(e,...t)}basenameOrAuthority(e){return p(e)||e.authority}basename(e){return r.SA.basename(e.path)}extname(e){return r.SA.extname(e.path)}dirname(e){if(0===e.path.length)return e;let t;return e.scheme===n.ny.file?t=l.r.file(r.pD(c(e))).path:(t=r.SA.dirname(e.path),e.authority&&t.length&&47!==t.charCodeAt(0)&&(console.error(`dirname("${e.toString})) resulted in a relative path`),t="/")),e.with({path:t})}normalizePath(e){if(!e.path.length)return e;let t;return t=e.scheme===n.ny.file?l.r.file(r.S8(c(e))).path:r.SA.normalize(e.path),e.with({path:t})}relativePath(e,t){if(e.scheme!==t.scheme||!E(e.authority,t.authority))return;if(e.scheme===n.ny.file){const i=r.V8(c(e),c(t));return o.uF?s.TH(i):i}let i=e.path||"/";const a=t.path||"/";if(this._ignorePathCasing(e)){let e=0;for(const t=Math.min(i.length,a.length);es.Zn(i).length&&i[i.length-1]===t}{const t=e.path;return t.length>1&&47===t.charCodeAt(t.length-1)&&!/^[a-zA-Z]:(\/$|\\$)/.test(e.fsPath)}}removeTrailingPathSeparator(e,t=r.Vn){return S(e,t)?e.with({path:e.path.substr(0,e.path.length-1)}):e}addTrailingPathSeparator(e,t=r.Vn){let i=!1;if(e.scheme===n.ny.file){const n=c(e);i=void 0!==n&&n.length===s.Zn(n).length&&n[n.length-1]===t}else{t="/";const s=e.path;i=1===s.length&&47===s.charCodeAt(s.length-1)}return i||S(e,t)?e:e.with({path:e.path+"/"})}}const d=new h((()=>!1)),u=(new h((e=>e.scheme!==n.ny.file||!o.j9)),new h((e=>!0)),d.isEqual.bind(d)),g=(d.isEqualOrParent.bind(d),d.getComparisonKey.bind(d),d.basenameOrAuthority.bind(d)),p=d.basename.bind(d),m=d.extname.bind(d),f=d.dirname.bind(d),_=d.joinPath.bind(d),v=d.normalizePath.bind(d),C=d.relativePath.bind(d),b=d.resolvePath.bind(d),E=(d.isAbsolutePath.bind(d),d.isEqualAuthority.bind(d)),S=d.hasTrailingPathSeparator.bind(d);d.removeTrailingPathSeparator.bind(d),d.addTrailingPathSeparator.bind(d);var y;!function(e){e.META_DATA_LABEL="label",e.META_DATA_DESCRIPTION="description",e.META_DATA_SIZE="size",e.META_DATA_MIME="mime",e.parseMetaData=function(t){const i=new Map;t.path.substring(t.path.indexOf(";")+1,t.path.lastIndexOf(";")).split(";").forEach((e=>{const[t,s]=e.split(":");t&&s&&i.set(t,s)}));const s=t.path.substring(0,t.path.indexOf(";"));return s&&i.set(e.META_DATA_MIME,s),i}}(y||(y={}))},49353:(e,t,i)=>{"use strict";i.d(t,{yE:()=>o});var s=i(41234),n=i(5662);class r{constructor(e,t,i,s,n,r,o){this._forceIntegerValues=e,this._scrollStateBrand=void 0,this._forceIntegerValues&&(t|=0,i|=0,s|=0,n|=0,r|=0,o|=0),this.rawScrollLeft=s,this.rawScrollTop=o,t<0&&(t=0),s+t>i&&(s=i-t),s<0&&(s=0),n<0&&(n=0),o+n>r&&(o=r-n),o<0&&(o=0),this.width=t,this.scrollWidth=i,this.scrollLeft=s,this.height=n,this.scrollHeight=r,this.scrollTop=o}equals(e){return this.rawScrollLeft===e.rawScrollLeft&&this.rawScrollTop===e.rawScrollTop&&this.width===e.width&&this.scrollWidth===e.scrollWidth&&this.scrollLeft===e.scrollLeft&&this.height===e.height&&this.scrollHeight===e.scrollHeight&&this.scrollTop===e.scrollTop}withScrollDimensions(e,t){return new r(this._forceIntegerValues,"undefined"!==typeof e.width?e.width:this.width,"undefined"!==typeof e.scrollWidth?e.scrollWidth:this.scrollWidth,t?this.rawScrollLeft:this.scrollLeft,"undefined"!==typeof e.height?e.height:this.height,"undefined"!==typeof e.scrollHeight?e.scrollHeight:this.scrollHeight,t?this.rawScrollTop:this.scrollTop)}withScrollPosition(e){return new r(this._forceIntegerValues,this.width,this.scrollWidth,"undefined"!==typeof e.scrollLeft?e.scrollLeft:this.rawScrollLeft,this.height,this.scrollHeight,"undefined"!==typeof e.scrollTop?e.scrollTop:this.rawScrollTop)}createScrollEvent(e,t){const i=this.width!==e.width,s=this.scrollWidth!==e.scrollWidth,n=this.scrollLeft!==e.scrollLeft,r=this.height!==e.height,o=this.scrollHeight!==e.scrollHeight,a=this.scrollTop!==e.scrollTop;return{inSmoothScrolling:t,oldWidth:e.width,oldScrollWidth:e.scrollWidth,oldScrollLeft:e.scrollLeft,width:this.width,scrollWidth:this.scrollWidth,scrollLeft:this.scrollLeft,oldHeight:e.height,oldScrollHeight:e.scrollHeight,oldScrollTop:e.scrollTop,height:this.height,scrollHeight:this.scrollHeight,scrollTop:this.scrollTop,widthChanged:i,scrollWidthChanged:s,scrollLeftChanged:n,heightChanged:r,scrollHeightChanged:o,scrollTopChanged:a}}}class o extends n.jG{constructor(e){super(),this._scrollableBrand=void 0,this._onScroll=this._register(new s.vl),this.onScroll=this._onScroll.event,this._smoothScrollDuration=e.smoothScrollDuration,this._scheduleAtNextAnimationFrame=e.scheduleAtNextAnimationFrame,this._state=new r(e.forceIntegerValues,0,0,0,0,0,0),this._smoothScrolling=null}dispose(){this._smoothScrolling&&(this._smoothScrolling.dispose(),this._smoothScrolling=null),super.dispose()}setSmoothScrollDuration(e){this._smoothScrollDuration=e}validateScrollPosition(e){return this._state.withScrollPosition(e)}getScrollDimensions(){return this._state}setScrollDimensions(e,t){const i=this._state.withScrollDimensions(e,t);this._setState(i,Boolean(this._smoothScrolling)),this._smoothScrolling?.acceptScrollDimensions(this._state)}getFutureScrollPosition(){return this._smoothScrolling?this._smoothScrolling.to:this._state}getCurrentScrollPosition(){return this._state}setScrollPositionNow(e){const t=this._state.withScrollPosition(e);this._smoothScrolling&&(this._smoothScrolling.dispose(),this._smoothScrolling=null),this._setState(t,!1)}setScrollPositionSmooth(e,t){if(0===this._smoothScrollDuration)return this.setScrollPositionNow(e);if(this._smoothScrolling){e={scrollLeft:"undefined"===typeof e.scrollLeft?this._smoothScrolling.to.scrollLeft:e.scrollLeft,scrollTop:"undefined"===typeof e.scrollTop?this._smoothScrolling.to.scrollTop:e.scrollTop};const i=this._state.withScrollPosition(e);if(this._smoothScrolling.to.scrollLeft===i.scrollLeft&&this._smoothScrolling.to.scrollTop===i.scrollTop)return;let s;s=t?new c(this._smoothScrolling.from,i,this._smoothScrolling.startTime,this._smoothScrolling.duration):this._smoothScrolling.combine(this._state,i,this._smoothScrollDuration),this._smoothScrolling.dispose(),this._smoothScrolling=s}else{const t=this._state.withScrollPosition(e);this._smoothScrolling=c.start(this._state,t,this._smoothScrollDuration)}this._smoothScrolling.animationFrameDisposable=this._scheduleAtNextAnimationFrame((()=>{this._smoothScrolling&&(this._smoothScrolling.animationFrameDisposable=null,this._performSmoothScrolling())}))}hasPendingScrollAnimation(){return Boolean(this._smoothScrolling)}_performSmoothScrolling(){if(!this._smoothScrolling)return;const e=this._smoothScrolling.tick(),t=this._state.withScrollPosition(e);return this._setState(t,!0),this._smoothScrolling?e.isDone?(this._smoothScrolling.dispose(),void(this._smoothScrolling=null)):void(this._smoothScrolling.animationFrameDisposable=this._scheduleAtNextAnimationFrame((()=>{this._smoothScrolling&&(this._smoothScrolling.animationFrameDisposable=null,this._performSmoothScrolling())}))):void 0}_setState(e,t){const i=this._state;i.equals(e)||(this._state=e,this._onScroll.fire(this._state.createScrollEvent(i,t)))}}class a{constructor(e,t,i){this.scrollLeft=e,this.scrollTop=t,this.isDone=i}}function l(e,t){const i=t-e;return function(t){return e+i*(1-function(e){return Math.pow(e,3)}(1-t))}}class c{constructor(e,t,i,s){this.from=e,this.to=t,this.duration=s,this.startTime=i,this.animationFrameDisposable=null,this._initAnimations()}_initAnimations(){this.scrollLeft=this._initAnimation(this.from.scrollLeft,this.to.scrollLeft,this.to.width),this.scrollTop=this._initAnimation(this.from.scrollTop,this.to.scrollTop,this.to.height)}_initAnimation(e,t,i){if(Math.abs(e-t)>2.5*i){let o,a;return e{"use strict";i.d(t,{A:()=>r});var s,n=i(91508);!function(e){e[e.Ignore=0]="Ignore",e[e.Info=1]="Info",e[e.Warning=2]="Warning",e[e.Error=3]="Error"}(s||(s={})),function(e){const t="error",i="warning",s="info";e.fromValue=function(r){return r?n.Q_(t,r)?e.Error:n.Q_(i,r)||n.Q_("warn",r)?e.Warning:n.Q_(s,r)?e.Info:e.Ignore:e.Ignore},e.toString=function(n){switch(n){case e.Error:return t;case e.Warning:return i;case e.Info:return s;default:return"ignore"}}}(s||(s={}));const r=s},78381:(e,t,i)=>{"use strict";i.d(t,{W:()=>n});const s=globalThis.performance&&"function"===typeof globalThis.performance.now;class n{static create(e){return new n(e)}constructor(e){this._now=s&&!1===e?Date.now:globalThis.performance.now.bind(globalThis.performance),this._startTime=this._now(),this._stopTime=-1}stop(){this._stopTime=this._now()}reset(){this._startTime=this._now(),this._stopTime=-1}elapsed(){return-1!==this._stopTime?this._stopTime-this._startTime:this._now()-this._startTime}}},91508:(e,t,i)=>{"use strict";i.d(t,{$X:()=>q,AV:()=>r,BO:()=>g,Bm:()=>p,Bq:()=>d,DB:()=>T,E_:()=>G,GP:()=>a,HG:()=>b,LJ:()=>M,LU:()=>Z,Lv:()=>x,MV:()=>W,NB:()=>u,OS:()=>f,Q_:()=>A,Qp:()=>I,S8:()=>re,Ss:()=>Q,UD:()=>y,UU:()=>E,Vi:()=>O,W1:()=>L,Wd:()=>se,Wv:()=>k,Z5:()=>F,_J:()=>Y,aC:()=>K,bm:()=>h,eY:()=>_,en:()=>C,ih:()=>c,iy:()=>B,jy:()=>l,km:()=>H,lF:()=>w,lT:()=>S,m:()=>V,ne:()=>$,ns:()=>N,pc:()=>D,r_:()=>X,tk:()=>ee,tl:()=>oe,uz:()=>v,wB:()=>m,y_:()=>ae,zY:()=>J,z_:()=>P,zd:()=>R});var s=i(81788),n=i(91090);function r(e){return!e||"string"!==typeof e||0===e.trim().length}const o=/{(\d+)}/g;function a(e,...t){return 0===t.length?e:e.replace(o,(function(e,i){const s=parseInt(i,10);return isNaN(s)||s<0||s>=t.length?e:t[s]}))}function l(e){return e.replace(/[<>"'&]/g,(e=>{switch(e){case"<":return"<";case">":return">";case'"':return""";case"'":return"'";case"&":return"&"}return e}))}function c(e){return e.replace(/[<>&]/g,(function(e){switch(e){case"<":return"<";case">":return">";case"&":return"&";default:return e}}))}function h(e){return e.replace(/[\\\{\}\*\+\?\|\^\$\.\[\]\(\)]/g,"\\$&")}function d(e,t=" "){return g(u(e,t),t)}function u(e,t){if(!e||!t)return e;const i=t.length;if(0===i||0===e.length)return e;let s=0;for(;e.indexOf(t,s)===s;)s+=i;return e.substring(s)}function g(e,t){if(!e||!t)return e;const i=t.length,s=e.length;if(0===i||0===s)return e;let n=s,r=-1;for(;r=e.lastIndexOf(t,n-1),-1!==r&&r+i===n;){if(0===r)return"";n=r}return e.substring(0,n)}function p(e){return e.replace(/[\-\\\{\}\+\?\|\^\$\.\,\[\]\(\)\#\s]/g,"\\$&").replace(/[\*]/g,".*")}function m(e){return e.replace(/\*/g,"")}function f(e,t,i={}){if(!e)throw new Error("Cannot create regex from empty string");t||(e=h(e)),i.wholeWord&&(/\B/.test(e.charAt(0))||(e="\\b"+e),/\B/.test(e.charAt(e.length-1))||(e+="\\b"));let s="";return i.global&&(s+="g"),i.matchCase||(s+="i"),i.multiline&&(s+="m"),i.unicode&&(s+="u"),new RegExp(e,s)}function _(e){if("^"===e.source||"^$"===e.source||"$"===e.source||"^\\s*$"===e.source)return!1;return!(!e.exec("")||0!==e.lastIndex)}function v(e){return e.split(/\r\n|\r|\n/)}function C(e){const t=[],i=e.split(/(\r\n|\r|\n)/);for(let s=0;s=0;i--){const t=e.charCodeAt(i);if(32!==t&&9!==t)return i}return-1}function y(e,t){return et?1:0}function w(e,t,i=0,s=e.length,n=0,r=t.length){for(;ir)return 1}const o=s-i,a=r-n;return oa?1:0}function L(e,t){return R(e,t,0,e.length,0,t.length)}function R(e,t,i=0,s=e.length,n=0,r=t.length){for(;i=128||a>=128)return w(e.toLowerCase(),t.toLowerCase(),i,s,n,r);x(o)&&(o-=32),x(a)&&(a-=32);const l=o-a;if(0!==l)return l}const o=s-i,a=r-n;return oa?1:0}function T(e){return e>=48&&e<=57}function x(e){return e>=97&&e<=122}function k(e){return e>=65&&e<=90}function A(e,t){return e.length===t.length&&0===R(e,t)}function N(e,t){const i=t.length;return!(t.length>e.length)&&0===R(e,t,0,i)}function I(e,t){const i=Math.min(e.length,t.length);let s;for(s=0;s1){const s=e.charCodeAt(t-2);if(D(s))return P(s,i)}return i}(this._str,this._offset);return this._offset-=e>=65536?2:1,e}nextCodePoint(){const e=F(this._str,this._len,this._offset);return this._offset+=e>=65536?2:1,e}eol(){return this._offset>=this._len}}class H{get offset(){return this._iterator.offset}constructor(e,t=0){this._iterator=new U(e,t)}nextGraphemeLength(){const e=ie.getInstance(),t=this._iterator,i=t.offset;let s=e.getGraphemeBreakType(t.nextCodePoint());for(;!t.eol();){const i=t.offset,n=e.getGraphemeBreakType(t.nextCodePoint());if(te(s,n)){t.setOffset(i);break}s=n}return t.offset-i}prevGraphemeLength(){const e=ie.getInstance(),t=this._iterator,i=t.offset;let s=e.getGraphemeBreakType(t.prevCodePoint());for(;t.offset>0;){const i=t.offset,n=e.getGraphemeBreakType(t.prevCodePoint());if(te(n,s)){t.setOffset(i);break}s=n}return i-t.offset}eol(){return this._iterator.eol()}}function B(e,t){return new H(e,t).nextGraphemeLength()}function W(e,t){return new H(e,t).prevGraphemeLength()}function V(e,t){t>0&&M(e.charCodeAt(t))&&t--;const i=t+B(e,t);return[i-W(e,i),i]}let z;function G(e){return z||(z=/(?:[\u05BE\u05C0\u05C3\u05C6\u05D0-\u05F4\u0608\u060B\u060D\u061B-\u064A\u066D-\u066F\u0671-\u06D5\u06E5\u06E6\u06EE\u06EF\u06FA-\u0710\u0712-\u072F\u074D-\u07A5\u07B1-\u07EA\u07F4\u07F5\u07FA\u07FE-\u0815\u081A\u0824\u0828\u0830-\u0858\u085E-\u088E\u08A0-\u08C9\u200F\uFB1D\uFB1F-\uFB28\uFB2A-\uFD3D\uFD50-\uFDC7\uFDF0-\uFDFC\uFE70-\uFEFC]|\uD802[\uDC00-\uDD1B\uDD20-\uDE00\uDE10-\uDE35\uDE40-\uDEE4\uDEEB-\uDF35\uDF40-\uDFFF]|\uD803[\uDC00-\uDD23\uDE80-\uDEA9\uDEAD-\uDF45\uDF51-\uDF81\uDF86-\uDFF6]|\uD83A[\uDC00-\uDCCF\uDD00-\uDD43\uDD4B-\uDFFF]|\uD83B[\uDC00-\uDEBB])/),z.test(e)}const j=/^[\t\n\r\x20-\x7E]*$/;function K(e){return j.test(e)}const Y=/[\u2028\u2029]/;function q(e){return Y.test(e)}function $(e){return e>=11904&&e<=55215||e>=63744&&e<=64255||e>=65281&&e<=65374}function Q(e){return e>=127462&&e<=127487||8986===e||8987===e||9200===e||9203===e||e>=9728&&e<=10175||11088===e||11093===e||e>=127744&&e<=128591||e>=128640&&e<=128764||e>=128992&&e<=129008||e>=129280&&e<=129535||e>=129648&&e<=129782}const X=String.fromCharCode(65279);function Z(e){return!!(e&&e.length>0&&65279===e.charCodeAt(0))}function J(e,t=!1){return!!e&&(t&&(e=e.replace(/\\./g,"")),e.toLowerCase()!==e)}function ee(e){return(e%=52)<26?String.fromCharCode(97+e):String.fromCharCode(65+e-26)}function te(e,t){return 0===e?5!==t&&7!==t:(2!==e||3!==t)&&(4===e||2===e||3===e||(4===t||2===t||3===t||(8!==e||8!==t&&9!==t&&11!==t&&12!==t)&&((11!==e&&9!==e||9!==t&&10!==t)&&((12!==e&&10!==e||10!==t)&&(5!==t&&13!==t&&(7!==t&&(1!==e&&((13!==e||14!==t)&&(6!==e||6!==t)))))))))}class ie{static{this._INSTANCE=null}static getInstance(){return ie._INSTANCE||(ie._INSTANCE=new ie),ie._INSTANCE}constructor(){this._data=JSON.parse("[0,0,0,51229,51255,12,44061,44087,12,127462,127487,6,7083,7085,5,47645,47671,12,54813,54839,12,128678,128678,14,3270,3270,5,9919,9923,14,45853,45879,12,49437,49463,12,53021,53047,12,71216,71218,7,128398,128399,14,129360,129374,14,2519,2519,5,4448,4519,9,9742,9742,14,12336,12336,14,44957,44983,12,46749,46775,12,48541,48567,12,50333,50359,12,52125,52151,12,53917,53943,12,69888,69890,5,73018,73018,5,127990,127990,14,128558,128559,14,128759,128760,14,129653,129655,14,2027,2035,5,2891,2892,7,3761,3761,5,6683,6683,5,8293,8293,4,9825,9826,14,9999,9999,14,43452,43453,5,44509,44535,12,45405,45431,12,46301,46327,12,47197,47223,12,48093,48119,12,48989,49015,12,49885,49911,12,50781,50807,12,51677,51703,12,52573,52599,12,53469,53495,12,54365,54391,12,65279,65279,4,70471,70472,7,72145,72147,7,119173,119179,5,127799,127818,14,128240,128244,14,128512,128512,14,128652,128652,14,128721,128722,14,129292,129292,14,129445,129450,14,129734,129743,14,1476,1477,5,2366,2368,7,2750,2752,7,3076,3076,5,3415,3415,5,4141,4144,5,6109,6109,5,6964,6964,5,7394,7400,5,9197,9198,14,9770,9770,14,9877,9877,14,9968,9969,14,10084,10084,14,43052,43052,5,43713,43713,5,44285,44311,12,44733,44759,12,45181,45207,12,45629,45655,12,46077,46103,12,46525,46551,12,46973,46999,12,47421,47447,12,47869,47895,12,48317,48343,12,48765,48791,12,49213,49239,12,49661,49687,12,50109,50135,12,50557,50583,12,51005,51031,12,51453,51479,12,51901,51927,12,52349,52375,12,52797,52823,12,53245,53271,12,53693,53719,12,54141,54167,12,54589,54615,12,55037,55063,12,69506,69509,5,70191,70193,5,70841,70841,7,71463,71467,5,72330,72342,5,94031,94031,5,123628,123631,5,127763,127765,14,127941,127941,14,128043,128062,14,128302,128317,14,128465,128467,14,128539,128539,14,128640,128640,14,128662,128662,14,128703,128703,14,128745,128745,14,129004,129007,14,129329,129330,14,129402,129402,14,129483,129483,14,129686,129704,14,130048,131069,14,173,173,4,1757,1757,1,2200,2207,5,2434,2435,7,2631,2632,5,2817,2817,5,3008,3008,5,3201,3201,5,3387,3388,5,3542,3542,5,3902,3903,7,4190,4192,5,6002,6003,5,6439,6440,5,6765,6770,7,7019,7027,5,7154,7155,7,8205,8205,13,8505,8505,14,9654,9654,14,9757,9757,14,9792,9792,14,9852,9853,14,9890,9894,14,9937,9937,14,9981,9981,14,10035,10036,14,11035,11036,14,42654,42655,5,43346,43347,7,43587,43587,5,44006,44007,7,44173,44199,12,44397,44423,12,44621,44647,12,44845,44871,12,45069,45095,12,45293,45319,12,45517,45543,12,45741,45767,12,45965,45991,12,46189,46215,12,46413,46439,12,46637,46663,12,46861,46887,12,47085,47111,12,47309,47335,12,47533,47559,12,47757,47783,12,47981,48007,12,48205,48231,12,48429,48455,12,48653,48679,12,48877,48903,12,49101,49127,12,49325,49351,12,49549,49575,12,49773,49799,12,49997,50023,12,50221,50247,12,50445,50471,12,50669,50695,12,50893,50919,12,51117,51143,12,51341,51367,12,51565,51591,12,51789,51815,12,52013,52039,12,52237,52263,12,52461,52487,12,52685,52711,12,52909,52935,12,53133,53159,12,53357,53383,12,53581,53607,12,53805,53831,12,54029,54055,12,54253,54279,12,54477,54503,12,54701,54727,12,54925,54951,12,55149,55175,12,68101,68102,5,69762,69762,7,70067,70069,7,70371,70378,5,70720,70721,7,71087,71087,5,71341,71341,5,71995,71996,5,72249,72249,7,72850,72871,5,73109,73109,5,118576,118598,5,121505,121519,5,127245,127247,14,127568,127569,14,127777,127777,14,127872,127891,14,127956,127967,14,128015,128016,14,128110,128172,14,128259,128259,14,128367,128368,14,128424,128424,14,128488,128488,14,128530,128532,14,128550,128551,14,128566,128566,14,128647,128647,14,128656,128656,14,128667,128673,14,128691,128693,14,128715,128715,14,128728,128732,14,128752,128752,14,128765,128767,14,129096,129103,14,129311,129311,14,129344,129349,14,129394,129394,14,129413,129425,14,129466,129471,14,129511,129535,14,129664,129666,14,129719,129722,14,129760,129767,14,917536,917631,5,13,13,2,1160,1161,5,1564,1564,4,1807,1807,1,2085,2087,5,2307,2307,7,2382,2383,7,2497,2500,5,2563,2563,7,2677,2677,5,2763,2764,7,2879,2879,5,2914,2915,5,3021,3021,5,3142,3144,5,3263,3263,5,3285,3286,5,3398,3400,7,3530,3530,5,3633,3633,5,3864,3865,5,3974,3975,5,4155,4156,7,4229,4230,5,5909,5909,7,6078,6085,7,6277,6278,5,6451,6456,7,6744,6750,5,6846,6846,5,6972,6972,5,7074,7077,5,7146,7148,7,7222,7223,5,7416,7417,5,8234,8238,4,8417,8417,5,9000,9000,14,9203,9203,14,9730,9731,14,9748,9749,14,9762,9763,14,9776,9783,14,9800,9811,14,9831,9831,14,9872,9873,14,9882,9882,14,9900,9903,14,9929,9933,14,9941,9960,14,9974,9974,14,9989,9989,14,10006,10006,14,10062,10062,14,10160,10160,14,11647,11647,5,12953,12953,14,43019,43019,5,43232,43249,5,43443,43443,5,43567,43568,7,43696,43696,5,43765,43765,7,44013,44013,5,44117,44143,12,44229,44255,12,44341,44367,12,44453,44479,12,44565,44591,12,44677,44703,12,44789,44815,12,44901,44927,12,45013,45039,12,45125,45151,12,45237,45263,12,45349,45375,12,45461,45487,12,45573,45599,12,45685,45711,12,45797,45823,12,45909,45935,12,46021,46047,12,46133,46159,12,46245,46271,12,46357,46383,12,46469,46495,12,46581,46607,12,46693,46719,12,46805,46831,12,46917,46943,12,47029,47055,12,47141,47167,12,47253,47279,12,47365,47391,12,47477,47503,12,47589,47615,12,47701,47727,12,47813,47839,12,47925,47951,12,48037,48063,12,48149,48175,12,48261,48287,12,48373,48399,12,48485,48511,12,48597,48623,12,48709,48735,12,48821,48847,12,48933,48959,12,49045,49071,12,49157,49183,12,49269,49295,12,49381,49407,12,49493,49519,12,49605,49631,12,49717,49743,12,49829,49855,12,49941,49967,12,50053,50079,12,50165,50191,12,50277,50303,12,50389,50415,12,50501,50527,12,50613,50639,12,50725,50751,12,50837,50863,12,50949,50975,12,51061,51087,12,51173,51199,12,51285,51311,12,51397,51423,12,51509,51535,12,51621,51647,12,51733,51759,12,51845,51871,12,51957,51983,12,52069,52095,12,52181,52207,12,52293,52319,12,52405,52431,12,52517,52543,12,52629,52655,12,52741,52767,12,52853,52879,12,52965,52991,12,53077,53103,12,53189,53215,12,53301,53327,12,53413,53439,12,53525,53551,12,53637,53663,12,53749,53775,12,53861,53887,12,53973,53999,12,54085,54111,12,54197,54223,12,54309,54335,12,54421,54447,12,54533,54559,12,54645,54671,12,54757,54783,12,54869,54895,12,54981,55007,12,55093,55119,12,55243,55291,10,66045,66045,5,68325,68326,5,69688,69702,5,69817,69818,5,69957,69958,7,70089,70092,5,70198,70199,5,70462,70462,5,70502,70508,5,70750,70750,5,70846,70846,7,71100,71101,5,71230,71230,7,71351,71351,5,71737,71738,5,72000,72000,7,72160,72160,5,72273,72278,5,72752,72758,5,72882,72883,5,73031,73031,5,73461,73462,7,94192,94193,7,119149,119149,7,121403,121452,5,122915,122916,5,126980,126980,14,127358,127359,14,127535,127535,14,127759,127759,14,127771,127771,14,127792,127793,14,127825,127867,14,127897,127899,14,127945,127945,14,127985,127986,14,128000,128007,14,128021,128021,14,128066,128100,14,128184,128235,14,128249,128252,14,128266,128276,14,128335,128335,14,128379,128390,14,128407,128419,14,128444,128444,14,128481,128481,14,128499,128499,14,128526,128526,14,128536,128536,14,128543,128543,14,128556,128556,14,128564,128564,14,128577,128580,14,128643,128645,14,128649,128649,14,128654,128654,14,128660,128660,14,128664,128664,14,128675,128675,14,128686,128689,14,128695,128696,14,128705,128709,14,128717,128719,14,128725,128725,14,128736,128741,14,128747,128748,14,128755,128755,14,128762,128762,14,128981,128991,14,129009,129023,14,129160,129167,14,129296,129304,14,129320,129327,14,129340,129342,14,129356,129356,14,129388,129392,14,129399,129400,14,129404,129407,14,129432,129442,14,129454,129455,14,129473,129474,14,129485,129487,14,129648,129651,14,129659,129660,14,129671,129679,14,129709,129711,14,129728,129730,14,129751,129753,14,129776,129782,14,917505,917505,4,917760,917999,5,10,10,3,127,159,4,768,879,5,1471,1471,5,1536,1541,1,1648,1648,5,1767,1768,5,1840,1866,5,2070,2073,5,2137,2139,5,2274,2274,1,2363,2363,7,2377,2380,7,2402,2403,5,2494,2494,5,2507,2508,7,2558,2558,5,2622,2624,7,2641,2641,5,2691,2691,7,2759,2760,5,2786,2787,5,2876,2876,5,2881,2884,5,2901,2902,5,3006,3006,5,3014,3016,7,3072,3072,5,3134,3136,5,3157,3158,5,3260,3260,5,3266,3266,5,3274,3275,7,3328,3329,5,3391,3392,7,3405,3405,5,3457,3457,5,3536,3537,7,3551,3551,5,3636,3642,5,3764,3772,5,3895,3895,5,3967,3967,7,3993,4028,5,4146,4151,5,4182,4183,7,4226,4226,5,4253,4253,5,4957,4959,5,5940,5940,7,6070,6070,7,6087,6088,7,6158,6158,4,6432,6434,5,6448,6449,7,6679,6680,5,6742,6742,5,6754,6754,5,6783,6783,5,6912,6915,5,6966,6970,5,6978,6978,5,7042,7042,7,7080,7081,5,7143,7143,7,7150,7150,7,7212,7219,5,7380,7392,5,7412,7412,5,8203,8203,4,8232,8232,4,8265,8265,14,8400,8412,5,8421,8432,5,8617,8618,14,9167,9167,14,9200,9200,14,9410,9410,14,9723,9726,14,9733,9733,14,9745,9745,14,9752,9752,14,9760,9760,14,9766,9766,14,9774,9774,14,9786,9786,14,9794,9794,14,9823,9823,14,9828,9828,14,9833,9850,14,9855,9855,14,9875,9875,14,9880,9880,14,9885,9887,14,9896,9897,14,9906,9916,14,9926,9927,14,9935,9935,14,9939,9939,14,9962,9962,14,9972,9972,14,9978,9978,14,9986,9986,14,9997,9997,14,10002,10002,14,10017,10017,14,10055,10055,14,10071,10071,14,10133,10135,14,10548,10549,14,11093,11093,14,12330,12333,5,12441,12442,5,42608,42610,5,43010,43010,5,43045,43046,5,43188,43203,7,43302,43309,5,43392,43394,5,43446,43449,5,43493,43493,5,43571,43572,7,43597,43597,7,43703,43704,5,43756,43757,5,44003,44004,7,44009,44010,7,44033,44059,12,44089,44115,12,44145,44171,12,44201,44227,12,44257,44283,12,44313,44339,12,44369,44395,12,44425,44451,12,44481,44507,12,44537,44563,12,44593,44619,12,44649,44675,12,44705,44731,12,44761,44787,12,44817,44843,12,44873,44899,12,44929,44955,12,44985,45011,12,45041,45067,12,45097,45123,12,45153,45179,12,45209,45235,12,45265,45291,12,45321,45347,12,45377,45403,12,45433,45459,12,45489,45515,12,45545,45571,12,45601,45627,12,45657,45683,12,45713,45739,12,45769,45795,12,45825,45851,12,45881,45907,12,45937,45963,12,45993,46019,12,46049,46075,12,46105,46131,12,46161,46187,12,46217,46243,12,46273,46299,12,46329,46355,12,46385,46411,12,46441,46467,12,46497,46523,12,46553,46579,12,46609,46635,12,46665,46691,12,46721,46747,12,46777,46803,12,46833,46859,12,46889,46915,12,46945,46971,12,47001,47027,12,47057,47083,12,47113,47139,12,47169,47195,12,47225,47251,12,47281,47307,12,47337,47363,12,47393,47419,12,47449,47475,12,47505,47531,12,47561,47587,12,47617,47643,12,47673,47699,12,47729,47755,12,47785,47811,12,47841,47867,12,47897,47923,12,47953,47979,12,48009,48035,12,48065,48091,12,48121,48147,12,48177,48203,12,48233,48259,12,48289,48315,12,48345,48371,12,48401,48427,12,48457,48483,12,48513,48539,12,48569,48595,12,48625,48651,12,48681,48707,12,48737,48763,12,48793,48819,12,48849,48875,12,48905,48931,12,48961,48987,12,49017,49043,12,49073,49099,12,49129,49155,12,49185,49211,12,49241,49267,12,49297,49323,12,49353,49379,12,49409,49435,12,49465,49491,12,49521,49547,12,49577,49603,12,49633,49659,12,49689,49715,12,49745,49771,12,49801,49827,12,49857,49883,12,49913,49939,12,49969,49995,12,50025,50051,12,50081,50107,12,50137,50163,12,50193,50219,12,50249,50275,12,50305,50331,12,50361,50387,12,50417,50443,12,50473,50499,12,50529,50555,12,50585,50611,12,50641,50667,12,50697,50723,12,50753,50779,12,50809,50835,12,50865,50891,12,50921,50947,12,50977,51003,12,51033,51059,12,51089,51115,12,51145,51171,12,51201,51227,12,51257,51283,12,51313,51339,12,51369,51395,12,51425,51451,12,51481,51507,12,51537,51563,12,51593,51619,12,51649,51675,12,51705,51731,12,51761,51787,12,51817,51843,12,51873,51899,12,51929,51955,12,51985,52011,12,52041,52067,12,52097,52123,12,52153,52179,12,52209,52235,12,52265,52291,12,52321,52347,12,52377,52403,12,52433,52459,12,52489,52515,12,52545,52571,12,52601,52627,12,52657,52683,12,52713,52739,12,52769,52795,12,52825,52851,12,52881,52907,12,52937,52963,12,52993,53019,12,53049,53075,12,53105,53131,12,53161,53187,12,53217,53243,12,53273,53299,12,53329,53355,12,53385,53411,12,53441,53467,12,53497,53523,12,53553,53579,12,53609,53635,12,53665,53691,12,53721,53747,12,53777,53803,12,53833,53859,12,53889,53915,12,53945,53971,12,54001,54027,12,54057,54083,12,54113,54139,12,54169,54195,12,54225,54251,12,54281,54307,12,54337,54363,12,54393,54419,12,54449,54475,12,54505,54531,12,54561,54587,12,54617,54643,12,54673,54699,12,54729,54755,12,54785,54811,12,54841,54867,12,54897,54923,12,54953,54979,12,55009,55035,12,55065,55091,12,55121,55147,12,55177,55203,12,65024,65039,5,65520,65528,4,66422,66426,5,68152,68154,5,69291,69292,5,69633,69633,5,69747,69748,5,69811,69814,5,69826,69826,5,69932,69932,7,70016,70017,5,70079,70080,7,70095,70095,5,70196,70196,5,70367,70367,5,70402,70403,7,70464,70464,5,70487,70487,5,70709,70711,7,70725,70725,7,70833,70834,7,70843,70844,7,70849,70849,7,71090,71093,5,71103,71104,5,71227,71228,7,71339,71339,5,71344,71349,5,71458,71461,5,71727,71735,5,71985,71989,7,71998,71998,5,72002,72002,7,72154,72155,5,72193,72202,5,72251,72254,5,72281,72283,5,72344,72345,5,72766,72766,7,72874,72880,5,72885,72886,5,73023,73029,5,73104,73105,5,73111,73111,5,92912,92916,5,94095,94098,5,113824,113827,4,119142,119142,7,119155,119162,4,119362,119364,5,121476,121476,5,122888,122904,5,123184,123190,5,125252,125258,5,127183,127183,14,127340,127343,14,127377,127386,14,127491,127503,14,127548,127551,14,127744,127756,14,127761,127761,14,127769,127769,14,127773,127774,14,127780,127788,14,127796,127797,14,127820,127823,14,127869,127869,14,127894,127895,14,127902,127903,14,127943,127943,14,127947,127950,14,127972,127972,14,127988,127988,14,127992,127994,14,128009,128011,14,128019,128019,14,128023,128041,14,128064,128064,14,128102,128107,14,128174,128181,14,128238,128238,14,128246,128247,14,128254,128254,14,128264,128264,14,128278,128299,14,128329,128330,14,128348,128359,14,128371,128377,14,128392,128393,14,128401,128404,14,128421,128421,14,128433,128434,14,128450,128452,14,128476,128478,14,128483,128483,14,128495,128495,14,128506,128506,14,128519,128520,14,128528,128528,14,128534,128534,14,128538,128538,14,128540,128542,14,128544,128549,14,128552,128555,14,128557,128557,14,128560,128563,14,128565,128565,14,128567,128576,14,128581,128591,14,128641,128642,14,128646,128646,14,128648,128648,14,128650,128651,14,128653,128653,14,128655,128655,14,128657,128659,14,128661,128661,14,128663,128663,14,128665,128666,14,128674,128674,14,128676,128677,14,128679,128685,14,128690,128690,14,128694,128694,14,128697,128702,14,128704,128704,14,128710,128714,14,128716,128716,14,128720,128720,14,128723,128724,14,128726,128727,14,128733,128735,14,128742,128744,14,128746,128746,14,128749,128751,14,128753,128754,14,128756,128758,14,128761,128761,14,128763,128764,14,128884,128895,14,128992,129003,14,129008,129008,14,129036,129039,14,129114,129119,14,129198,129279,14,129293,129295,14,129305,129310,14,129312,129319,14,129328,129328,14,129331,129338,14,129343,129343,14,129351,129355,14,129357,129359,14,129375,129387,14,129393,129393,14,129395,129398,14,129401,129401,14,129403,129403,14,129408,129412,14,129426,129431,14,129443,129444,14,129451,129453,14,129456,129465,14,129472,129472,14,129475,129482,14,129484,129484,14,129488,129510,14,129536,129647,14,129652,129652,14,129656,129658,14,129661,129663,14,129667,129670,14,129680,129685,14,129705,129708,14,129712,129718,14,129723,129727,14,129731,129733,14,129744,129750,14,129754,129759,14,129768,129775,14,129783,129791,14,917504,917504,4,917506,917535,4,917632,917759,4,918000,921599,4,0,9,4,11,12,4,14,31,4,169,169,14,174,174,14,1155,1159,5,1425,1469,5,1473,1474,5,1479,1479,5,1552,1562,5,1611,1631,5,1750,1756,5,1759,1764,5,1770,1773,5,1809,1809,5,1958,1968,5,2045,2045,5,2075,2083,5,2089,2093,5,2192,2193,1,2250,2273,5,2275,2306,5,2362,2362,5,2364,2364,5,2369,2376,5,2381,2381,5,2385,2391,5,2433,2433,5,2492,2492,5,2495,2496,7,2503,2504,7,2509,2509,5,2530,2531,5,2561,2562,5,2620,2620,5,2625,2626,5,2635,2637,5,2672,2673,5,2689,2690,5,2748,2748,5,2753,2757,5,2761,2761,7,2765,2765,5,2810,2815,5,2818,2819,7,2878,2878,5,2880,2880,7,2887,2888,7,2893,2893,5,2903,2903,5,2946,2946,5,3007,3007,7,3009,3010,7,3018,3020,7,3031,3031,5,3073,3075,7,3132,3132,5,3137,3140,7,3146,3149,5,3170,3171,5,3202,3203,7,3262,3262,7,3264,3265,7,3267,3268,7,3271,3272,7,3276,3277,5,3298,3299,5,3330,3331,7,3390,3390,5,3393,3396,5,3402,3404,7,3406,3406,1,3426,3427,5,3458,3459,7,3535,3535,5,3538,3540,5,3544,3550,7,3570,3571,7,3635,3635,7,3655,3662,5,3763,3763,7,3784,3789,5,3893,3893,5,3897,3897,5,3953,3966,5,3968,3972,5,3981,3991,5,4038,4038,5,4145,4145,7,4153,4154,5,4157,4158,5,4184,4185,5,4209,4212,5,4228,4228,7,4237,4237,5,4352,4447,8,4520,4607,10,5906,5908,5,5938,5939,5,5970,5971,5,6068,6069,5,6071,6077,5,6086,6086,5,6089,6099,5,6155,6157,5,6159,6159,5,6313,6313,5,6435,6438,7,6441,6443,7,6450,6450,5,6457,6459,5,6681,6682,7,6741,6741,7,6743,6743,7,6752,6752,5,6757,6764,5,6771,6780,5,6832,6845,5,6847,6862,5,6916,6916,7,6965,6965,5,6971,6971,7,6973,6977,7,6979,6980,7,7040,7041,5,7073,7073,7,7078,7079,7,7082,7082,7,7142,7142,5,7144,7145,5,7149,7149,5,7151,7153,5,7204,7211,7,7220,7221,7,7376,7378,5,7393,7393,7,7405,7405,5,7415,7415,7,7616,7679,5,8204,8204,5,8206,8207,4,8233,8233,4,8252,8252,14,8288,8292,4,8294,8303,4,8413,8416,5,8418,8420,5,8482,8482,14,8596,8601,14,8986,8987,14,9096,9096,14,9193,9196,14,9199,9199,14,9201,9202,14,9208,9210,14,9642,9643,14,9664,9664,14,9728,9729,14,9732,9732,14,9735,9741,14,9743,9744,14,9746,9746,14,9750,9751,14,9753,9756,14,9758,9759,14,9761,9761,14,9764,9765,14,9767,9769,14,9771,9773,14,9775,9775,14,9784,9785,14,9787,9791,14,9793,9793,14,9795,9799,14,9812,9822,14,9824,9824,14,9827,9827,14,9829,9830,14,9832,9832,14,9851,9851,14,9854,9854,14,9856,9861,14,9874,9874,14,9876,9876,14,9878,9879,14,9881,9881,14,9883,9884,14,9888,9889,14,9895,9895,14,9898,9899,14,9904,9905,14,9917,9918,14,9924,9925,14,9928,9928,14,9934,9934,14,9936,9936,14,9938,9938,14,9940,9940,14,9961,9961,14,9963,9967,14,9970,9971,14,9973,9973,14,9975,9977,14,9979,9980,14,9982,9985,14,9987,9988,14,9992,9996,14,9998,9998,14,10000,10001,14,10004,10004,14,10013,10013,14,10024,10024,14,10052,10052,14,10060,10060,14,10067,10069,14,10083,10083,14,10085,10087,14,10145,10145,14,10175,10175,14,11013,11015,14,11088,11088,14,11503,11505,5,11744,11775,5,12334,12335,5,12349,12349,14,12951,12951,14,42607,42607,5,42612,42621,5,42736,42737,5,43014,43014,5,43043,43044,7,43047,43047,7,43136,43137,7,43204,43205,5,43263,43263,5,43335,43345,5,43360,43388,8,43395,43395,7,43444,43445,7,43450,43451,7,43454,43456,7,43561,43566,5,43569,43570,5,43573,43574,5,43596,43596,5,43644,43644,5,43698,43700,5,43710,43711,5,43755,43755,7,43758,43759,7,43766,43766,5,44005,44005,5,44008,44008,5,44012,44012,7,44032,44032,11,44060,44060,11,44088,44088,11,44116,44116,11,44144,44144,11,44172,44172,11,44200,44200,11,44228,44228,11,44256,44256,11,44284,44284,11,44312,44312,11,44340,44340,11,44368,44368,11,44396,44396,11,44424,44424,11,44452,44452,11,44480,44480,11,44508,44508,11,44536,44536,11,44564,44564,11,44592,44592,11,44620,44620,11,44648,44648,11,44676,44676,11,44704,44704,11,44732,44732,11,44760,44760,11,44788,44788,11,44816,44816,11,44844,44844,11,44872,44872,11,44900,44900,11,44928,44928,11,44956,44956,11,44984,44984,11,45012,45012,11,45040,45040,11,45068,45068,11,45096,45096,11,45124,45124,11,45152,45152,11,45180,45180,11,45208,45208,11,45236,45236,11,45264,45264,11,45292,45292,11,45320,45320,11,45348,45348,11,45376,45376,11,45404,45404,11,45432,45432,11,45460,45460,11,45488,45488,11,45516,45516,11,45544,45544,11,45572,45572,11,45600,45600,11,45628,45628,11,45656,45656,11,45684,45684,11,45712,45712,11,45740,45740,11,45768,45768,11,45796,45796,11,45824,45824,11,45852,45852,11,45880,45880,11,45908,45908,11,45936,45936,11,45964,45964,11,45992,45992,11,46020,46020,11,46048,46048,11,46076,46076,11,46104,46104,11,46132,46132,11,46160,46160,11,46188,46188,11,46216,46216,11,46244,46244,11,46272,46272,11,46300,46300,11,46328,46328,11,46356,46356,11,46384,46384,11,46412,46412,11,46440,46440,11,46468,46468,11,46496,46496,11,46524,46524,11,46552,46552,11,46580,46580,11,46608,46608,11,46636,46636,11,46664,46664,11,46692,46692,11,46720,46720,11,46748,46748,11,46776,46776,11,46804,46804,11,46832,46832,11,46860,46860,11,46888,46888,11,46916,46916,11,46944,46944,11,46972,46972,11,47000,47000,11,47028,47028,11,47056,47056,11,47084,47084,11,47112,47112,11,47140,47140,11,47168,47168,11,47196,47196,11,47224,47224,11,47252,47252,11,47280,47280,11,47308,47308,11,47336,47336,11,47364,47364,11,47392,47392,11,47420,47420,11,47448,47448,11,47476,47476,11,47504,47504,11,47532,47532,11,47560,47560,11,47588,47588,11,47616,47616,11,47644,47644,11,47672,47672,11,47700,47700,11,47728,47728,11,47756,47756,11,47784,47784,11,47812,47812,11,47840,47840,11,47868,47868,11,47896,47896,11,47924,47924,11,47952,47952,11,47980,47980,11,48008,48008,11,48036,48036,11,48064,48064,11,48092,48092,11,48120,48120,11,48148,48148,11,48176,48176,11,48204,48204,11,48232,48232,11,48260,48260,11,48288,48288,11,48316,48316,11,48344,48344,11,48372,48372,11,48400,48400,11,48428,48428,11,48456,48456,11,48484,48484,11,48512,48512,11,48540,48540,11,48568,48568,11,48596,48596,11,48624,48624,11,48652,48652,11,48680,48680,11,48708,48708,11,48736,48736,11,48764,48764,11,48792,48792,11,48820,48820,11,48848,48848,11,48876,48876,11,48904,48904,11,48932,48932,11,48960,48960,11,48988,48988,11,49016,49016,11,49044,49044,11,49072,49072,11,49100,49100,11,49128,49128,11,49156,49156,11,49184,49184,11,49212,49212,11,49240,49240,11,49268,49268,11,49296,49296,11,49324,49324,11,49352,49352,11,49380,49380,11,49408,49408,11,49436,49436,11,49464,49464,11,49492,49492,11,49520,49520,11,49548,49548,11,49576,49576,11,49604,49604,11,49632,49632,11,49660,49660,11,49688,49688,11,49716,49716,11,49744,49744,11,49772,49772,11,49800,49800,11,49828,49828,11,49856,49856,11,49884,49884,11,49912,49912,11,49940,49940,11,49968,49968,11,49996,49996,11,50024,50024,11,50052,50052,11,50080,50080,11,50108,50108,11,50136,50136,11,50164,50164,11,50192,50192,11,50220,50220,11,50248,50248,11,50276,50276,11,50304,50304,11,50332,50332,11,50360,50360,11,50388,50388,11,50416,50416,11,50444,50444,11,50472,50472,11,50500,50500,11,50528,50528,11,50556,50556,11,50584,50584,11,50612,50612,11,50640,50640,11,50668,50668,11,50696,50696,11,50724,50724,11,50752,50752,11,50780,50780,11,50808,50808,11,50836,50836,11,50864,50864,11,50892,50892,11,50920,50920,11,50948,50948,11,50976,50976,11,51004,51004,11,51032,51032,11,51060,51060,11,51088,51088,11,51116,51116,11,51144,51144,11,51172,51172,11,51200,51200,11,51228,51228,11,51256,51256,11,51284,51284,11,51312,51312,11,51340,51340,11,51368,51368,11,51396,51396,11,51424,51424,11,51452,51452,11,51480,51480,11,51508,51508,11,51536,51536,11,51564,51564,11,51592,51592,11,51620,51620,11,51648,51648,11,51676,51676,11,51704,51704,11,51732,51732,11,51760,51760,11,51788,51788,11,51816,51816,11,51844,51844,11,51872,51872,11,51900,51900,11,51928,51928,11,51956,51956,11,51984,51984,11,52012,52012,11,52040,52040,11,52068,52068,11,52096,52096,11,52124,52124,11,52152,52152,11,52180,52180,11,52208,52208,11,52236,52236,11,52264,52264,11,52292,52292,11,52320,52320,11,52348,52348,11,52376,52376,11,52404,52404,11,52432,52432,11,52460,52460,11,52488,52488,11,52516,52516,11,52544,52544,11,52572,52572,11,52600,52600,11,52628,52628,11,52656,52656,11,52684,52684,11,52712,52712,11,52740,52740,11,52768,52768,11,52796,52796,11,52824,52824,11,52852,52852,11,52880,52880,11,52908,52908,11,52936,52936,11,52964,52964,11,52992,52992,11,53020,53020,11,53048,53048,11,53076,53076,11,53104,53104,11,53132,53132,11,53160,53160,11,53188,53188,11,53216,53216,11,53244,53244,11,53272,53272,11,53300,53300,11,53328,53328,11,53356,53356,11,53384,53384,11,53412,53412,11,53440,53440,11,53468,53468,11,53496,53496,11,53524,53524,11,53552,53552,11,53580,53580,11,53608,53608,11,53636,53636,11,53664,53664,11,53692,53692,11,53720,53720,11,53748,53748,11,53776,53776,11,53804,53804,11,53832,53832,11,53860,53860,11,53888,53888,11,53916,53916,11,53944,53944,11,53972,53972,11,54000,54000,11,54028,54028,11,54056,54056,11,54084,54084,11,54112,54112,11,54140,54140,11,54168,54168,11,54196,54196,11,54224,54224,11,54252,54252,11,54280,54280,11,54308,54308,11,54336,54336,11,54364,54364,11,54392,54392,11,54420,54420,11,54448,54448,11,54476,54476,11,54504,54504,11,54532,54532,11,54560,54560,11,54588,54588,11,54616,54616,11,54644,54644,11,54672,54672,11,54700,54700,11,54728,54728,11,54756,54756,11,54784,54784,11,54812,54812,11,54840,54840,11,54868,54868,11,54896,54896,11,54924,54924,11,54952,54952,11,54980,54980,11,55008,55008,11,55036,55036,11,55064,55064,11,55092,55092,11,55120,55120,11,55148,55148,11,55176,55176,11,55216,55238,9,64286,64286,5,65056,65071,5,65438,65439,5,65529,65531,4,66272,66272,5,68097,68099,5,68108,68111,5,68159,68159,5,68900,68903,5,69446,69456,5,69632,69632,7,69634,69634,7,69744,69744,5,69759,69761,5,69808,69810,7,69815,69816,7,69821,69821,1,69837,69837,1,69927,69931,5,69933,69940,5,70003,70003,5,70018,70018,7,70070,70078,5,70082,70083,1,70094,70094,7,70188,70190,7,70194,70195,7,70197,70197,7,70206,70206,5,70368,70370,7,70400,70401,5,70459,70460,5,70463,70463,7,70465,70468,7,70475,70477,7,70498,70499,7,70512,70516,5,70712,70719,5,70722,70724,5,70726,70726,5,70832,70832,5,70835,70840,5,70842,70842,5,70845,70845,5,70847,70848,5,70850,70851,5,71088,71089,7,71096,71099,7,71102,71102,7,71132,71133,5,71219,71226,5,71229,71229,5,71231,71232,5,71340,71340,7,71342,71343,7,71350,71350,7,71453,71455,5,71462,71462,7,71724,71726,7,71736,71736,7,71984,71984,5,71991,71992,7,71997,71997,7,71999,71999,1,72001,72001,1,72003,72003,5,72148,72151,5,72156,72159,7,72164,72164,7,72243,72248,5,72250,72250,1,72263,72263,5,72279,72280,7,72324,72329,1,72343,72343,7,72751,72751,7,72760,72765,5,72767,72767,5,72873,72873,7,72881,72881,7,72884,72884,7,73009,73014,5,73020,73021,5,73030,73030,1,73098,73102,7,73107,73108,7,73110,73110,7,73459,73460,5,78896,78904,4,92976,92982,5,94033,94087,7,94180,94180,5,113821,113822,5,118528,118573,5,119141,119141,5,119143,119145,5,119150,119154,5,119163,119170,5,119210,119213,5,121344,121398,5,121461,121461,5,121499,121503,5,122880,122886,5,122907,122913,5,122918,122922,5,123566,123566,5,125136,125142,5,126976,126979,14,126981,127182,14,127184,127231,14,127279,127279,14,127344,127345,14,127374,127374,14,127405,127461,14,127489,127490,14,127514,127514,14,127538,127546,14,127561,127567,14,127570,127743,14,127757,127758,14,127760,127760,14,127762,127762,14,127766,127768,14,127770,127770,14,127772,127772,14,127775,127776,14,127778,127779,14,127789,127791,14,127794,127795,14,127798,127798,14,127819,127819,14,127824,127824,14,127868,127868,14,127870,127871,14,127892,127893,14,127896,127896,14,127900,127901,14,127904,127940,14,127942,127942,14,127944,127944,14,127946,127946,14,127951,127955,14,127968,127971,14,127973,127984,14,127987,127987,14,127989,127989,14,127991,127991,14,127995,127999,5,128008,128008,14,128012,128014,14,128017,128018,14,128020,128020,14,128022,128022,14,128042,128042,14,128063,128063,14,128065,128065,14,128101,128101,14,128108,128109,14,128173,128173,14,128182,128183,14,128236,128237,14,128239,128239,14,128245,128245,14,128248,128248,14,128253,128253,14,128255,128258,14,128260,128263,14,128265,128265,14,128277,128277,14,128300,128301,14,128326,128328,14,128331,128334,14,128336,128347,14,128360,128366,14,128369,128370,14,128378,128378,14,128391,128391,14,128394,128397,14,128400,128400,14,128405,128406,14,128420,128420,14,128422,128423,14,128425,128432,14,128435,128443,14,128445,128449,14,128453,128464,14,128468,128475,14,128479,128480,14,128482,128482,14,128484,128487,14,128489,128494,14,128496,128498,14,128500,128505,14,128507,128511,14,128513,128518,14,128521,128525,14,128527,128527,14,128529,128529,14,128533,128533,14,128535,128535,14,128537,128537,14]")}getGraphemeBreakType(e){if(e<32)return 10===e?3:13===e?2:4;if(e<127)return 0;const t=this._data,i=t.length/3;let s=1;for(;s<=i;)if(et[3*s+1]))return t[3*s+2];s=2*s+1}return 0}}function se(e,t){if(0===e)return 0;const i=function(e,t){const i=new U(t,e);let s=i.prevCodePoint();for(;ne(s)||65039===s||8419===s;){if(0===i.offset)return;s=i.prevCodePoint()}if(!Q(s))return;let n=i.offset;if(n>0){8205===i.prevCodePoint()&&(n=i.offset)}return n}(e,t);if(void 0!==i)return i;const s=new U(t,e);return s.prevCodePoint(),s.offset}function ne(e){return 127995<=e&&e<=127999}const re="\xa0";class oe{static{this.ambiguousCharacterData=new n.d((()=>JSON.parse('{"_common":[8232,32,8233,32,5760,32,8192,32,8193,32,8194,32,8195,32,8196,32,8197,32,8198,32,8200,32,8201,32,8202,32,8287,32,8199,32,8239,32,2042,95,65101,95,65102,95,65103,95,8208,45,8209,45,8210,45,65112,45,1748,45,8259,45,727,45,8722,45,10134,45,11450,45,1549,44,1643,44,8218,44,184,44,42233,44,894,59,2307,58,2691,58,1417,58,1795,58,1796,58,5868,58,65072,58,6147,58,6153,58,8282,58,1475,58,760,58,42889,58,8758,58,720,58,42237,58,451,33,11601,33,660,63,577,63,2429,63,5038,63,42731,63,119149,46,8228,46,1793,46,1794,46,42510,46,68176,46,1632,46,1776,46,42232,46,1373,96,65287,96,8219,96,8242,96,1370,96,1523,96,8175,96,65344,96,900,96,8189,96,8125,96,8127,96,8190,96,697,96,884,96,712,96,714,96,715,96,756,96,699,96,701,96,700,96,702,96,42892,96,1497,96,2036,96,2037,96,5194,96,5836,96,94033,96,94034,96,65339,91,10088,40,10098,40,12308,40,64830,40,65341,93,10089,41,10099,41,12309,41,64831,41,10100,123,119060,123,10101,125,65342,94,8270,42,1645,42,8727,42,66335,42,5941,47,8257,47,8725,47,8260,47,9585,47,10187,47,10744,47,119354,47,12755,47,12339,47,11462,47,20031,47,12035,47,65340,92,65128,92,8726,92,10189,92,10741,92,10745,92,119311,92,119355,92,12756,92,20022,92,12034,92,42872,38,708,94,710,94,5869,43,10133,43,66203,43,8249,60,10094,60,706,60,119350,60,5176,60,5810,60,5120,61,11840,61,12448,61,42239,61,8250,62,10095,62,707,62,119351,62,5171,62,94015,62,8275,126,732,126,8128,126,8764,126,65372,124,65293,45,120784,50,120794,50,120804,50,120814,50,120824,50,130034,50,42842,50,423,50,1000,50,42564,50,5311,50,42735,50,119302,51,120785,51,120795,51,120805,51,120815,51,120825,51,130035,51,42923,51,540,51,439,51,42858,51,11468,51,1248,51,94011,51,71882,51,120786,52,120796,52,120806,52,120816,52,120826,52,130036,52,5070,52,71855,52,120787,53,120797,53,120807,53,120817,53,120827,53,130037,53,444,53,71867,53,120788,54,120798,54,120808,54,120818,54,120828,54,130038,54,11474,54,5102,54,71893,54,119314,55,120789,55,120799,55,120809,55,120819,55,120829,55,130039,55,66770,55,71878,55,2819,56,2538,56,2666,56,125131,56,120790,56,120800,56,120810,56,120820,56,120830,56,130040,56,547,56,546,56,66330,56,2663,57,2920,57,2541,57,3437,57,120791,57,120801,57,120811,57,120821,57,120831,57,130041,57,42862,57,11466,57,71884,57,71852,57,71894,57,9082,97,65345,97,119834,97,119886,97,119938,97,119990,97,120042,97,120094,97,120146,97,120198,97,120250,97,120302,97,120354,97,120406,97,120458,97,593,97,945,97,120514,97,120572,97,120630,97,120688,97,120746,97,65313,65,119808,65,119860,65,119912,65,119964,65,120016,65,120068,65,120120,65,120172,65,120224,65,120276,65,120328,65,120380,65,120432,65,913,65,120488,65,120546,65,120604,65,120662,65,120720,65,5034,65,5573,65,42222,65,94016,65,66208,65,119835,98,119887,98,119939,98,119991,98,120043,98,120095,98,120147,98,120199,98,120251,98,120303,98,120355,98,120407,98,120459,98,388,98,5071,98,5234,98,5551,98,65314,66,8492,66,119809,66,119861,66,119913,66,120017,66,120069,66,120121,66,120173,66,120225,66,120277,66,120329,66,120381,66,120433,66,42932,66,914,66,120489,66,120547,66,120605,66,120663,66,120721,66,5108,66,5623,66,42192,66,66178,66,66209,66,66305,66,65347,99,8573,99,119836,99,119888,99,119940,99,119992,99,120044,99,120096,99,120148,99,120200,99,120252,99,120304,99,120356,99,120408,99,120460,99,7428,99,1010,99,11429,99,43951,99,66621,99,128844,67,71922,67,71913,67,65315,67,8557,67,8450,67,8493,67,119810,67,119862,67,119914,67,119966,67,120018,67,120174,67,120226,67,120278,67,120330,67,120382,67,120434,67,1017,67,11428,67,5087,67,42202,67,66210,67,66306,67,66581,67,66844,67,8574,100,8518,100,119837,100,119889,100,119941,100,119993,100,120045,100,120097,100,120149,100,120201,100,120253,100,120305,100,120357,100,120409,100,120461,100,1281,100,5095,100,5231,100,42194,100,8558,68,8517,68,119811,68,119863,68,119915,68,119967,68,120019,68,120071,68,120123,68,120175,68,120227,68,120279,68,120331,68,120383,68,120435,68,5024,68,5598,68,5610,68,42195,68,8494,101,65349,101,8495,101,8519,101,119838,101,119890,101,119942,101,120046,101,120098,101,120150,101,120202,101,120254,101,120306,101,120358,101,120410,101,120462,101,43826,101,1213,101,8959,69,65317,69,8496,69,119812,69,119864,69,119916,69,120020,69,120072,69,120124,69,120176,69,120228,69,120280,69,120332,69,120384,69,120436,69,917,69,120492,69,120550,69,120608,69,120666,69,120724,69,11577,69,5036,69,42224,69,71846,69,71854,69,66182,69,119839,102,119891,102,119943,102,119995,102,120047,102,120099,102,120151,102,120203,102,120255,102,120307,102,120359,102,120411,102,120463,102,43829,102,42905,102,383,102,7837,102,1412,102,119315,70,8497,70,119813,70,119865,70,119917,70,120021,70,120073,70,120125,70,120177,70,120229,70,120281,70,120333,70,120385,70,120437,70,42904,70,988,70,120778,70,5556,70,42205,70,71874,70,71842,70,66183,70,66213,70,66853,70,65351,103,8458,103,119840,103,119892,103,119944,103,120048,103,120100,103,120152,103,120204,103,120256,103,120308,103,120360,103,120412,103,120464,103,609,103,7555,103,397,103,1409,103,119814,71,119866,71,119918,71,119970,71,120022,71,120074,71,120126,71,120178,71,120230,71,120282,71,120334,71,120386,71,120438,71,1292,71,5056,71,5107,71,42198,71,65352,104,8462,104,119841,104,119945,104,119997,104,120049,104,120101,104,120153,104,120205,104,120257,104,120309,104,120361,104,120413,104,120465,104,1211,104,1392,104,5058,104,65320,72,8459,72,8460,72,8461,72,119815,72,119867,72,119919,72,120023,72,120179,72,120231,72,120283,72,120335,72,120387,72,120439,72,919,72,120494,72,120552,72,120610,72,120668,72,120726,72,11406,72,5051,72,5500,72,42215,72,66255,72,731,105,9075,105,65353,105,8560,105,8505,105,8520,105,119842,105,119894,105,119946,105,119998,105,120050,105,120102,105,120154,105,120206,105,120258,105,120310,105,120362,105,120414,105,120466,105,120484,105,618,105,617,105,953,105,8126,105,890,105,120522,105,120580,105,120638,105,120696,105,120754,105,1110,105,42567,105,1231,105,43893,105,5029,105,71875,105,65354,106,8521,106,119843,106,119895,106,119947,106,119999,106,120051,106,120103,106,120155,106,120207,106,120259,106,120311,106,120363,106,120415,106,120467,106,1011,106,1112,106,65322,74,119817,74,119869,74,119921,74,119973,74,120025,74,120077,74,120129,74,120181,74,120233,74,120285,74,120337,74,120389,74,120441,74,42930,74,895,74,1032,74,5035,74,5261,74,42201,74,119844,107,119896,107,119948,107,120000,107,120052,107,120104,107,120156,107,120208,107,120260,107,120312,107,120364,107,120416,107,120468,107,8490,75,65323,75,119818,75,119870,75,119922,75,119974,75,120026,75,120078,75,120130,75,120182,75,120234,75,120286,75,120338,75,120390,75,120442,75,922,75,120497,75,120555,75,120613,75,120671,75,120729,75,11412,75,5094,75,5845,75,42199,75,66840,75,1472,108,8739,73,9213,73,65512,73,1633,108,1777,73,66336,108,125127,108,120783,73,120793,73,120803,73,120813,73,120823,73,130033,73,65321,73,8544,73,8464,73,8465,73,119816,73,119868,73,119920,73,120024,73,120128,73,120180,73,120232,73,120284,73,120336,73,120388,73,120440,73,65356,108,8572,73,8467,108,119845,108,119897,108,119949,108,120001,108,120053,108,120105,73,120157,73,120209,73,120261,73,120313,73,120365,73,120417,73,120469,73,448,73,120496,73,120554,73,120612,73,120670,73,120728,73,11410,73,1030,73,1216,73,1493,108,1503,108,1575,108,126464,108,126592,108,65166,108,65165,108,1994,108,11599,73,5825,73,42226,73,93992,73,66186,124,66313,124,119338,76,8556,76,8466,76,119819,76,119871,76,119923,76,120027,76,120079,76,120131,76,120183,76,120235,76,120287,76,120339,76,120391,76,120443,76,11472,76,5086,76,5290,76,42209,76,93974,76,71843,76,71858,76,66587,76,66854,76,65325,77,8559,77,8499,77,119820,77,119872,77,119924,77,120028,77,120080,77,120132,77,120184,77,120236,77,120288,77,120340,77,120392,77,120444,77,924,77,120499,77,120557,77,120615,77,120673,77,120731,77,1018,77,11416,77,5047,77,5616,77,5846,77,42207,77,66224,77,66321,77,119847,110,119899,110,119951,110,120003,110,120055,110,120107,110,120159,110,120211,110,120263,110,120315,110,120367,110,120419,110,120471,110,1400,110,1404,110,65326,78,8469,78,119821,78,119873,78,119925,78,119977,78,120029,78,120081,78,120185,78,120237,78,120289,78,120341,78,120393,78,120445,78,925,78,120500,78,120558,78,120616,78,120674,78,120732,78,11418,78,42208,78,66835,78,3074,111,3202,111,3330,111,3458,111,2406,111,2662,111,2790,111,3046,111,3174,111,3302,111,3430,111,3664,111,3792,111,4160,111,1637,111,1781,111,65359,111,8500,111,119848,111,119900,111,119952,111,120056,111,120108,111,120160,111,120212,111,120264,111,120316,111,120368,111,120420,111,120472,111,7439,111,7441,111,43837,111,959,111,120528,111,120586,111,120644,111,120702,111,120760,111,963,111,120532,111,120590,111,120648,111,120706,111,120764,111,11423,111,4351,111,1413,111,1505,111,1607,111,126500,111,126564,111,126596,111,65259,111,65260,111,65258,111,65257,111,1726,111,64428,111,64429,111,64427,111,64426,111,1729,111,64424,111,64425,111,64423,111,64422,111,1749,111,3360,111,4125,111,66794,111,71880,111,71895,111,66604,111,1984,79,2534,79,2918,79,12295,79,70864,79,71904,79,120782,79,120792,79,120802,79,120812,79,120822,79,130032,79,65327,79,119822,79,119874,79,119926,79,119978,79,120030,79,120082,79,120134,79,120186,79,120238,79,120290,79,120342,79,120394,79,120446,79,927,79,120502,79,120560,79,120618,79,120676,79,120734,79,11422,79,1365,79,11604,79,4816,79,2848,79,66754,79,42227,79,71861,79,66194,79,66219,79,66564,79,66838,79,9076,112,65360,112,119849,112,119901,112,119953,112,120005,112,120057,112,120109,112,120161,112,120213,112,120265,112,120317,112,120369,112,120421,112,120473,112,961,112,120530,112,120544,112,120588,112,120602,112,120646,112,120660,112,120704,112,120718,112,120762,112,120776,112,11427,112,65328,80,8473,80,119823,80,119875,80,119927,80,119979,80,120031,80,120083,80,120187,80,120239,80,120291,80,120343,80,120395,80,120447,80,929,80,120504,80,120562,80,120620,80,120678,80,120736,80,11426,80,5090,80,5229,80,42193,80,66197,80,119850,113,119902,113,119954,113,120006,113,120058,113,120110,113,120162,113,120214,113,120266,113,120318,113,120370,113,120422,113,120474,113,1307,113,1379,113,1382,113,8474,81,119824,81,119876,81,119928,81,119980,81,120032,81,120084,81,120188,81,120240,81,120292,81,120344,81,120396,81,120448,81,11605,81,119851,114,119903,114,119955,114,120007,114,120059,114,120111,114,120163,114,120215,114,120267,114,120319,114,120371,114,120423,114,120475,114,43847,114,43848,114,7462,114,11397,114,43905,114,119318,82,8475,82,8476,82,8477,82,119825,82,119877,82,119929,82,120033,82,120189,82,120241,82,120293,82,120345,82,120397,82,120449,82,422,82,5025,82,5074,82,66740,82,5511,82,42211,82,94005,82,65363,115,119852,115,119904,115,119956,115,120008,115,120060,115,120112,115,120164,115,120216,115,120268,115,120320,115,120372,115,120424,115,120476,115,42801,115,445,115,1109,115,43946,115,71873,115,66632,115,65331,83,119826,83,119878,83,119930,83,119982,83,120034,83,120086,83,120138,83,120190,83,120242,83,120294,83,120346,83,120398,83,120450,83,1029,83,1359,83,5077,83,5082,83,42210,83,94010,83,66198,83,66592,83,119853,116,119905,116,119957,116,120009,116,120061,116,120113,116,120165,116,120217,116,120269,116,120321,116,120373,116,120425,116,120477,116,8868,84,10201,84,128872,84,65332,84,119827,84,119879,84,119931,84,119983,84,120035,84,120087,84,120139,84,120191,84,120243,84,120295,84,120347,84,120399,84,120451,84,932,84,120507,84,120565,84,120623,84,120681,84,120739,84,11430,84,5026,84,42196,84,93962,84,71868,84,66199,84,66225,84,66325,84,119854,117,119906,117,119958,117,120010,117,120062,117,120114,117,120166,117,120218,117,120270,117,120322,117,120374,117,120426,117,120478,117,42911,117,7452,117,43854,117,43858,117,651,117,965,117,120534,117,120592,117,120650,117,120708,117,120766,117,1405,117,66806,117,71896,117,8746,85,8899,85,119828,85,119880,85,119932,85,119984,85,120036,85,120088,85,120140,85,120192,85,120244,85,120296,85,120348,85,120400,85,120452,85,1357,85,4608,85,66766,85,5196,85,42228,85,94018,85,71864,85,8744,118,8897,118,65366,118,8564,118,119855,118,119907,118,119959,118,120011,118,120063,118,120115,118,120167,118,120219,118,120271,118,120323,118,120375,118,120427,118,120479,118,7456,118,957,118,120526,118,120584,118,120642,118,120700,118,120758,118,1141,118,1496,118,71430,118,43945,118,71872,118,119309,86,1639,86,1783,86,8548,86,119829,86,119881,86,119933,86,119985,86,120037,86,120089,86,120141,86,120193,86,120245,86,120297,86,120349,86,120401,86,120453,86,1140,86,11576,86,5081,86,5167,86,42719,86,42214,86,93960,86,71840,86,66845,86,623,119,119856,119,119908,119,119960,119,120012,119,120064,119,120116,119,120168,119,120220,119,120272,119,120324,119,120376,119,120428,119,120480,119,7457,119,1121,119,1309,119,1377,119,71434,119,71438,119,71439,119,43907,119,71919,87,71910,87,119830,87,119882,87,119934,87,119986,87,120038,87,120090,87,120142,87,120194,87,120246,87,120298,87,120350,87,120402,87,120454,87,1308,87,5043,87,5076,87,42218,87,5742,120,10539,120,10540,120,10799,120,65368,120,8569,120,119857,120,119909,120,119961,120,120013,120,120065,120,120117,120,120169,120,120221,120,120273,120,120325,120,120377,120,120429,120,120481,120,5441,120,5501,120,5741,88,9587,88,66338,88,71916,88,65336,88,8553,88,119831,88,119883,88,119935,88,119987,88,120039,88,120091,88,120143,88,120195,88,120247,88,120299,88,120351,88,120403,88,120455,88,42931,88,935,88,120510,88,120568,88,120626,88,120684,88,120742,88,11436,88,11613,88,5815,88,42219,88,66192,88,66228,88,66327,88,66855,88,611,121,7564,121,65369,121,119858,121,119910,121,119962,121,120014,121,120066,121,120118,121,120170,121,120222,121,120274,121,120326,121,120378,121,120430,121,120482,121,655,121,7935,121,43866,121,947,121,8509,121,120516,121,120574,121,120632,121,120690,121,120748,121,1199,121,4327,121,71900,121,65337,89,119832,89,119884,89,119936,89,119988,89,120040,89,120092,89,120144,89,120196,89,120248,89,120300,89,120352,89,120404,89,120456,89,933,89,978,89,120508,89,120566,89,120624,89,120682,89,120740,89,11432,89,1198,89,5033,89,5053,89,42220,89,94019,89,71844,89,66226,89,119859,122,119911,122,119963,122,120015,122,120067,122,120119,122,120171,122,120223,122,120275,122,120327,122,120379,122,120431,122,120483,122,7458,122,43923,122,71876,122,66293,90,71909,90,65338,90,8484,90,8488,90,119833,90,119885,90,119937,90,119989,90,120041,90,120197,90,120249,90,120301,90,120353,90,120405,90,120457,90,918,90,120493,90,120551,90,120609,90,120667,90,120725,90,5059,90,42204,90,71849,90,65282,34,65284,36,65285,37,65286,38,65290,42,65291,43,65294,46,65295,47,65296,48,65297,49,65298,50,65299,51,65300,52,65301,53,65302,54,65303,55,65304,56,65305,57,65308,60,65309,61,65310,62,65312,64,65316,68,65318,70,65319,71,65324,76,65329,81,65330,82,65333,85,65334,86,65335,87,65343,95,65346,98,65348,100,65350,102,65355,107,65357,109,65358,110,65361,113,65362,114,65364,116,65365,117,65367,119,65370,122,65371,123,65373,125,119846,109],"_default":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"cs":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"de":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"es":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"fr":[65374,126,65306,58,65281,33,8216,96,8245,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"it":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ja":[8211,45,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65292,44,65307,59],"ko":[8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pl":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"pt-BR":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"qps-ploc":[160,32,8211,45,65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"ru":[65374,126,65306,58,65281,33,8216,96,8217,96,8245,96,180,96,12494,47,305,105,921,73,1009,112,215,120,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"tr":[160,32,8211,45,65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65288,40,65289,41,65292,44,65307,59,65311,63],"zh-hans":[65374,126,65306,58,65281,33,8245,96,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65288,40,65289,41],"zh-hant":[8211,45,65374,126,180,96,12494,47,1047,51,1073,54,1072,97,1040,65,1068,98,1042,66,1089,99,1057,67,1077,101,1045,69,1053,72,305,105,1050,75,921,73,1052,77,1086,111,1054,79,1009,112,1088,112,1056,80,1075,114,1058,84,215,120,1093,120,1061,88,1091,121,1059,89,65283,35,65307,59]}')))}static{this.cache=new s.o5({getCacheKey:JSON.stringify},(e=>{function t(e){const t=new Map;for(let i=0;i!e.startsWith("_")&&e in s));0===r.length&&(r=["_default"]);for(const a of r){n=i(n,t(s[a]))}const o=function(e,t){const i=new Map(e);for(const[s,n]of t)i.set(s,n);return i}(t(s._common),n);return new oe(o)}))}static getInstance(e){return oe.cache.get(Array.from(e))}static{this._locales=new n.d((()=>Object.keys(oe.ambiguousCharacterData.value).filter((e=>!e.startsWith("_")))))}static getLocales(){return oe._locales.value}constructor(e){this.confusableDictionary=e}isAmbiguous(e){return this.confusableDictionary.has(e)}getPrimaryConfusable(e){return this.confusableDictionary.get(e)}getConfusableCodePoints(){return new Set(this.confusableDictionary.keys())}}class ae{static getRawData(){return JSON.parse("[9,10,11,12,13,32,127,160,173,847,1564,4447,4448,6068,6069,6155,6156,6157,6158,7355,7356,8192,8193,8194,8195,8196,8197,8198,8199,8200,8201,8202,8203,8204,8205,8206,8207,8234,8235,8236,8237,8238,8239,8287,8288,8289,8290,8291,8292,8293,8294,8295,8296,8297,8298,8299,8300,8301,8302,8303,10240,12288,12644,65024,65025,65026,65027,65028,65029,65030,65031,65032,65033,65034,65035,65036,65037,65038,65039,65279,65440,65520,65521,65522,65523,65524,65525,65526,65527,65528,65532,78844,119155,119156,119157,119158,119159,119160,119161,119162,917504,917505,917506,917507,917508,917509,917510,917511,917512,917513,917514,917515,917516,917517,917518,917519,917520,917521,917522,917523,917524,917525,917526,917527,917528,917529,917530,917531,917532,917533,917534,917535,917536,917537,917538,917539,917540,917541,917542,917543,917544,917545,917546,917547,917548,917549,917550,917551,917552,917553,917554,917555,917556,917557,917558,917559,917560,917561,917562,917563,917564,917565,917566,917567,917568,917569,917570,917571,917572,917573,917574,917575,917576,917577,917578,917579,917580,917581,917582,917583,917584,917585,917586,917587,917588,917589,917590,917591,917592,917593,917594,917595,917596,917597,917598,917599,917600,917601,917602,917603,917604,917605,917606,917607,917608,917609,917610,917611,917612,917613,917614,917615,917616,917617,917618,917619,917620,917621,917622,917623,917624,917625,917626,917627,917628,917629,917630,917631,917760,917761,917762,917763,917764,917765,917766,917767,917768,917769,917770,917771,917772,917773,917774,917775,917776,917777,917778,917779,917780,917781,917782,917783,917784,917785,917786,917787,917788,917789,917790,917791,917792,917793,917794,917795,917796,917797,917798,917799,917800,917801,917802,917803,917804,917805,917806,917807,917808,917809,917810,917811,917812,917813,917814,917815,917816,917817,917818,917819,917820,917821,917822,917823,917824,917825,917826,917827,917828,917829,917830,917831,917832,917833,917834,917835,917836,917837,917838,917839,917840,917841,917842,917843,917844,917845,917846,917847,917848,917849,917850,917851,917852,917853,917854,917855,917856,917857,917858,917859,917860,917861,917862,917863,917864,917865,917866,917867,917868,917869,917870,917871,917872,917873,917874,917875,917876,917877,917878,917879,917880,917881,917882,917883,917884,917885,917886,917887,917888,917889,917890,917891,917892,917893,917894,917895,917896,917897,917898,917899,917900,917901,917902,917903,917904,917905,917906,917907,917908,917909,917910,917911,917912,917913,917914,917915,917916,917917,917918,917919,917920,917921,917922,917923,917924,917925,917926,917927,917928,917929,917930,917931,917932,917933,917934,917935,917936,917937,917938,917939,917940,917941,917942,917943,917944,917945,917946,917947,917948,917949,917950,917951,917952,917953,917954,917955,917956,917957,917958,917959,917960,917961,917962,917963,917964,917965,917966,917967,917968,917969,917970,917971,917972,917973,917974,917975,917976,917977,917978,917979,917980,917981,917982,917983,917984,917985,917986,917987,917988,917989,917990,917991,917992,917993,917994,917995,917996,917997,917998,917999]")}static{this._data=void 0}static getData(){return this._data||(this._data=new Set(ae.getRawData())),this._data}static isInvisibleCharacter(e){return ae.getData().has(e)}static get codePoints(){return ae.getData()}}},44759:(e,t,i)=>{"use strict";i.d(t,{h:()=>s});const s=Symbol("MicrotaskDelay")},4853:(e,t,i)=>{"use strict";i.d(t,{cB:()=>c});var s=i(91508);class n{constructor(){this._value="",this._pos=0}reset(e){return this._value=e,this._pos=0,this}next(){return this._pos+=1,this}hasNext(){return this._pos=0;t--,this._valueLen--){const e=this._value.charCodeAt(t);if(!(47===e||this._splitOnBackslash&&92===e))break}return this.next()}hasNext(){return this._to!1,t=()=>!1){return new c(new a(e,t))}static forStrings(){return new c(new n)}static forConfigKeys(){return new c(new r)}constructor(e){this._iter=e}clear(){this._root=void 0}set(e,t){const i=this._iter.reset(e);let s;this._root||(this._root=new l,this._root.segment=i.value());const n=[];for(s=this._root;;){const e=i.cmp(s.segment);if(e>0)s.left||(s.left=new l,s.left.segment=i.value()),n.push([-1,s]),s=s.left;else if(e<0)s.right||(s.right=new l,s.right.segment=i.value()),n.push([1,s]),s=s.right;else{if(!i.hasNext())break;i.next(),s.mid||(s.mid=new l,s.mid.segment=i.value()),n.push([0,s]),s=s.mid}}const r=s.value;s.value=t,s.key=e;for(let o=n.length-1;o>=0;o--){const e=n[o][1];e.updateHeight();const t=e.balanceFactor();if(t<-1||t>1){const t=n[o][0],i=n[o+1][0];if(1===t&&1===i)n[o][1]=e.rotateLeft();else if(-1===t&&-1===i)n[o][1]=e.rotateRight();else if(1===t&&-1===i)e.right=n[o+1][1]=n[o+1][1].rotateRight(),n[o][1]=e.rotateLeft();else{if(-1!==t||1!==i)throw new Error;e.left=n[o+1][1]=n[o+1][1].rotateLeft(),n[o][1]=e.rotateRight()}if(o>0)switch(n[o-1][0]){case-1:n[o-1][1].left=n[o][1];break;case 1:n[o-1][1].right=n[o][1];break;case 0:n[o-1][1].mid=n[o][1]}else this._root=n[0][1]}}return r}get(e){return this._getNode(e)?.value}_getNode(e){const t=this._iter.reset(e);let i=this._root;for(;i;){const e=t.cmp(i.segment);if(e>0)i=i.left;else if(e<0)i=i.right;else{if(!t.hasNext())break;t.next(),i=i.mid}}return i}has(e){const t=this._getNode(e);return!(void 0===t?.value&&void 0===t?.mid)}delete(e){return this._delete(e,!1)}deleteSuperstr(e){return this._delete(e,!0)}_delete(e,t){const i=this._iter.reset(e),s=[];let n=this._root;for(;n;){const e=i.cmp(n.segment);if(e>0)s.push([-1,n]),n=n.left;else if(e<0)s.push([1,n]),n=n.right;else{if(!i.hasNext())break;i.next(),s.push([0,n]),n=n.mid}}if(n){if(t?(n.left=void 0,n.mid=void 0,n.right=void 0,n.height=1):(n.key=void 0,n.value=void 0),!n.mid&&!n.value)if(n.left&&n.right){const e=this._min(n.right);if(e.key){const{key:t,value:i,segment:s}=e;this._delete(e.key,!1),n.key=t,n.value=i,n.segment=s}}else{const e=n.left??n.right;if(s.length>0){const[t,i]=s[s.length-1];switch(t){case-1:i.left=e;break;case 0:i.mid=e;break;case 1:i.right=e}}else this._root=e}for(let e=s.length-1;e>=0;e--){const t=s[e][1];t.updateHeight();const i=t.balanceFactor();if(i>1?(t.right.balanceFactor()>=0||(t.right=t.right.rotateRight()),s[e][1]=t.rotateLeft()):i<-1&&(t.left.balanceFactor()<=0||(t.left=t.left.rotateLeft()),s[e][1]=t.rotateRight()),e>0)switch(s[e-1][0]){case-1:s[e-1][1].left=s[e][1];break;case 1:s[e-1][1].right=s[e][1];break;case 0:s[e-1][1].mid=s[e][1]}else this._root=s[0][1]}}}_min(e){for(;e.left;)e=e.left;return e}findSubstr(e){const t=this._iter.reset(e);let i,s=this._root;for(;s;){const e=t.cmp(s.segment);if(e>0)s=s.left;else if(e<0)s=s.right;else{if(!t.hasNext())break;t.next(),i=s.value||i,s=s.mid}}return s&&s.value||i}findSuperstr(e){return this._findSuperstrOrElement(e,!1)}_findSuperstrOrElement(e,t){const i=this._iter.reset(e);let s=this._root;for(;s;){const e=i.cmp(s.segment);if(e>0)s=s.left;else if(e<0)s=s.right;else{if(!i.hasNext())return s.mid?this._entries(s.mid):t?s.value:void 0;i.next(),s=s.mid}}}forEach(e){for(const[t,i]of this)e(i,t)}*[Symbol.iterator](){yield*this._entries(this._root)}_entries(e){const t=[];return this._dfsEntries(e,t),t[Symbol.iterator]()}_dfsEntries(e,t){e&&(e.left&&this._dfsEntries(e.left,t),e.value&&t.push([e.key,e.value]),e.mid&&this._dfsEntries(e.mid,t),e.right&&this._dfsEntries(e.right,t))}}},25689:(e,t,i)=>{"use strict";i.d(t,{L:()=>n});var s,n,r=i(10350);!function(e){e.isThemeColor=function(e){return e&&"object"===typeof e&&"string"===typeof e.id}}(s||(s={})),function(e){e.iconNameSegment="[A-Za-z0-9]+",e.iconNameExpression="[A-Za-z0-9-]+",e.iconModifierExpression="~[A-Za-z]+",e.iconNameCharacter="[A-Za-z0-9~-]";const t=new RegExp(`^(${e.iconNameExpression})(${e.iconModifierExpression})?$`);function i(e){const s=t.exec(e.id);if(!s)return i(r.W.error);const[,n,o]=s,a=["codicon","codicon-"+n];return o&&a.push("codicon-modifier-"+o.substring(1)),a}e.asClassNameArray=i,e.asClassName=function(e){return i(e).join(" ")},e.asCSSSelector=function(e){return"."+i(e).join(".")},e.isThemeIcon=function(e){return e&&"object"===typeof e&&"string"===typeof e.id&&("undefined"===typeof e.color||s.isThemeColor(e.color))};const n=new RegExp(`^\\$\\((${e.iconNameExpression}(?:${e.iconModifierExpression})?)\\)$`);e.fromString=function(e){const t=n.exec(e);if(!t)return;const[,i]=t;return{id:i}},e.fromId=function(e){return{id:e}},e.modify=function(e,t){let i=e.id;const s=i.lastIndexOf("~");return-1!==s&&(i=i.substring(0,s)),t&&(i=`${i}~${t}`),{id:i}},e.getModifier=function(e){const t=e.id.lastIndexOf("~");if(-1!==t)return e.id.substring(t+1)},e.isEqual=function(e,t){return e.id===t.id&&e.color?.id===t.color?.id}}(n||(n={}))},631:(e,t,i)=>{"use strict";function s(e){return"string"===typeof e}function n(e){return"object"===typeof e&&null!==e&&!Array.isArray(e)&&!(e instanceof RegExp)&&!(e instanceof Date)}function r(e){const t=Object.getPrototypeOf(Uint8Array);return"object"===typeof e&&e instanceof t}function o(e){return"number"===typeof e&&!isNaN(e)}function a(e){return!!e&&"function"===typeof e[Symbol.iterator]}function l(e){return!0===e||!1===e}function c(e){return"undefined"===typeof e}function h(e){return!d(e)}function d(e){return c(e)||null===e}function u(e,t){if(!e)throw new Error(t?`Unexpected type, expected '${t}'`:"Unexpected type")}function g(e){if(d(e))throw new Error("Assertion Failed: argument is undefined or null");return e}function p(e){return"function"===typeof e}function m(e,t){const i=Math.min(e.length,t.length);for(let s=0;so,Gv:()=>n,Kg:()=>s,Lm:()=>l,O9:()=>h,Tn:()=>p,b0:()=>c,eU:()=>g,iu:()=>r,j:()=>u,jx:()=>m,xZ:()=>a,z:()=>d})},85152:(e,t,i)=>{"use strict";function s(e){return e<0?0:e>255?255:0|e}function n(e){return e<0?0:e>4294967295?4294967295:0|e}i.d(t,{W:()=>s,j:()=>n})},79400:(e,t,i)=>{"use strict";i.d(t,{I:()=>_,r:()=>d});var s=i(74027),n=i(98067);const r=/^\w[\w\d+.-]*$/,o=/^\//,a=/^\/\//;const l="",c="/",h=/^(([^:/?#]+?):)?(\/\/([^/?#]*))?([^?#]*)(\?([^#]*))?(#(.*))?/;class d{static isUri(e){return e instanceof d||!!e&&("string"===typeof e.authority&&"string"===typeof e.fragment&&"string"===typeof e.path&&"string"===typeof e.query&&"string"===typeof e.scheme&&"string"===typeof e.fsPath&&"function"===typeof e.with&&"function"===typeof e.toString)}constructor(e,t,i,s,n,h=!1){"object"===typeof e?(this.scheme=e.scheme||l,this.authority=e.authority||l,this.path=e.path||l,this.query=e.query||l,this.fragment=e.fragment||l):(this.scheme=function(e,t){return e||t?e:"file"}(e,h),this.authority=t||l,this.path=function(e,t){switch(e){case"https":case"http":case"file":t?t[0]!==c&&(t=c+t):t=c}return t}(this.scheme,i||l),this.query=s||l,this.fragment=n||l,function(e,t){if(!e.scheme&&t)throw new Error(`[UriError]: Scheme is missing: {scheme: "", authority: "${e.authority}", path: "${e.path}", query: "${e.query}", fragment: "${e.fragment}"}`);if(e.scheme&&!r.test(e.scheme))throw new Error("[UriError]: Scheme contains illegal characters.");if(e.path)if(e.authority){if(!o.test(e.path))throw new Error('[UriError]: If a URI contains an authority component, then the path component must either be empty or begin with a slash ("/") character')}else if(a.test(e.path))throw new Error('[UriError]: If a URI does not contain an authority component, then the path cannot begin with two slash characters ("//")')}(this,h))}get fsPath(){return _(this,!1)}with(e){if(!e)return this;let{scheme:t,authority:i,path:s,query:n,fragment:r}=e;return void 0===t?t=this.scheme:null===t&&(t=l),void 0===i?i=this.authority:null===i&&(i=l),void 0===s?s=this.path:null===s&&(s=l),void 0===n?n=this.query:null===n&&(n=l),void 0===r?r=this.fragment:null===r&&(r=l),t===this.scheme&&i===this.authority&&s===this.path&&n===this.query&&r===this.fragment?this:new g(t,i,s,n,r)}static parse(e,t=!1){const i=h.exec(e);return i?new g(i[2]||l,E(i[4]||l),E(i[5]||l),E(i[7]||l),E(i[9]||l),t):new g(l,l,l,l,l)}static file(e){let t=l;if(n.uF&&(e=e.replace(/\\/g,c)),e[0]===c&&e[1]===c){const i=e.indexOf(c,2);-1===i?(t=e.substring(2),e=c):(t=e.substring(2,i),e=e.substring(i)||c)}return new g("file",t,e,l,l)}static from(e,t){return new g(e.scheme,e.authority,e.path,e.query,e.fragment,t)}static joinPath(e,...t){if(!e.path)throw new Error("[UriError]: cannot call joinPath on URI without path");let i;return i=n.uF&&"file"===e.scheme?d.file(s.IN.join(_(e,!0),...t)).path:s.SA.join(e.path,...t),e.with({path:i})}toString(e=!1){return v(this,e)}toJSON(){return this}static revive(e){if(e){if(e instanceof d)return e;{const t=new g(e);return t._formatted=e.external??null,t._fsPath=e._sep===u?e.fsPath??null:null,t}}return e}}const u=n.uF?1:void 0;class g extends d{constructor(){super(...arguments),this._formatted=null,this._fsPath=null}get fsPath(){return this._fsPath||(this._fsPath=_(this,!1)),this._fsPath}toString(e=!1){return e?v(this,!0):(this._formatted||(this._formatted=v(this,!1)),this._formatted)}toJSON(){const e={$mid:1};return this._fsPath&&(e.fsPath=this._fsPath,e._sep=u),this._formatted&&(e.external=this._formatted),this.path&&(e.path=this.path),this.scheme&&(e.scheme=this.scheme),this.authority&&(e.authority=this.authority),this.query&&(e.query=this.query),this.fragment&&(e.fragment=this.fragment),e}}const p={58:"%3A",47:"%2F",63:"%3F",35:"%23",91:"%5B",93:"%5D",64:"%40",33:"%21",36:"%24",38:"%26",39:"%27",40:"%28",41:"%29",42:"%2A",43:"%2B",44:"%2C",59:"%3B",61:"%3D",32:"%20"};function m(e,t,i){let s,n=-1;for(let r=0;r=97&&o<=122||o>=65&&o<=90||o>=48&&o<=57||45===o||46===o||95===o||126===o||t&&47===o||i&&91===o||i&&93===o||i&&58===o)-1!==n&&(s+=encodeURIComponent(e.substring(n,r)),n=-1),void 0!==s&&(s+=e.charAt(r));else{void 0===s&&(s=e.substr(0,r));const t=p[o];void 0!==t?(-1!==n&&(s+=encodeURIComponent(e.substring(n,r)),n=-1),s+=t):-1===n&&(n=r)}}return-1!==n&&(s+=encodeURIComponent(e.substring(n))),void 0!==s?s:e}function f(e){let t;for(let i=0;i1&&"file"===e.scheme?`//${e.authority}${e.path}`:47===e.path.charCodeAt(0)&&(e.path.charCodeAt(1)>=65&&e.path.charCodeAt(1)<=90||e.path.charCodeAt(1)>=97&&e.path.charCodeAt(1)<=122)&&58===e.path.charCodeAt(2)?t?e.path.substr(1):e.path[1].toLowerCase()+e.path.substr(2):e.path,n.uF&&(i=i.replace(/\//g,"\\")),i}function v(e,t){const i=t?f:m;let s="",{scheme:n,authority:r,path:o,query:a,fragment:l}=e;if(n&&(s+=n,s+=":"),(r||"file"===n)&&(s+=c,s+=c),r){let e=r.indexOf("@");if(-1!==e){const t=r.substr(0,e);r=r.substr(e+1),e=t.lastIndexOf(":"),-1===e?s+=i(t,!1,!1):(s+=i(t.substr(0,e),!1,!1),s+=":",s+=i(t.substr(e+1),!1,!0)),s+="@"}r=r.toLowerCase(),e=r.lastIndexOf(":"),-1===e?s+=i(r,!1,!0):(s+=i(r.substr(0,e),!1,!0),s+=r.substr(e))}if(o){if(o.length>=3&&47===o.charCodeAt(0)&&58===o.charCodeAt(2)){const e=o.charCodeAt(1);e>=65&&e<=90&&(o=`/${String.fromCharCode(e+32)}:${o.substr(3)}`)}else if(o.length>=2&&58===o.charCodeAt(1)){const e=o.charCodeAt(0);e>=65&&e<=90&&(o=`${String.fromCharCode(e+32)}:${o.substr(2)}`)}s+=i(o,!0,!1)}return a&&(s+="?",s+=i(a,!1,!1)),l&&(s+="#",s+=t?l:m(l,!1,!1)),s}function C(e){try{return decodeURIComponent(e)}catch{return e.length>3?e.substr(0,3)+C(e.substr(3)):e}}const b=/(%[0-9A-Za-z][0-9A-Za-z])+/g;function E(e){return e.match(b)?e.replace(b,(e=>C(e))):e}},58255:(e,t,i)=>{"use strict";i.d(t,{b:()=>s});const s=function(){if("object"===typeof crypto&&"function"===typeof crypto.randomUUID)return crypto.randomUUID.bind(crypto);let e;e="object"===typeof crypto&&"function"===typeof crypto.getRandomValues?crypto.getRandomValues.bind(crypto):function(e){for(let t=0;t{"use strict";i.r(t),i.d(t,{SimpleWorkerClient:()=>C,SimpleWorkerServer:()=>S,create:()=>y,logOnceWebWorkerWarning:()=>u});var s=i(64383),n=i(41234),r=i(5662),o=i(36456),a=i(98067),l=i(91508);const c="default",h="$initialize";let d=!1;function u(e){a.HZ&&(d||(d=!0,console.warn("Could not create web worker(s). Falling back to loading web worker code in main thread, which might cause UI freezes. Please see https://github.com/microsoft/monaco-editor#faq")),console.warn(e.message))}class g{constructor(e,t,i,s,n){this.vsWorker=e,this.req=t,this.channel=i,this.method=s,this.args=n,this.type=0}}class p{constructor(e,t,i,s){this.vsWorker=e,this.seq=t,this.res=i,this.err=s,this.type=1}}class m{constructor(e,t,i,s,n){this.vsWorker=e,this.req=t,this.channel=i,this.eventName=s,this.arg=n,this.type=2}}class f{constructor(e,t,i){this.vsWorker=e,this.req=t,this.event=i,this.type=3}}class _{constructor(e,t){this.vsWorker=e,this.req=t,this.type=4}}class v{constructor(e){this._workerId=-1,this._handler=e,this._lastSentReq=0,this._pendingReplies=Object.create(null),this._pendingEmitters=new Map,this._pendingEvents=new Map}setWorkerId(e){this._workerId=e}sendMessage(e,t,i){const s=String(++this._lastSentReq);return new Promise(((n,r)=>{this._pendingReplies[s]={resolve:n,reject:r},this._send(new g(this._workerId,s,e,t,i))}))}listen(e,t,i){let s=null;const r=new n.vl({onWillAddFirstListener:()=>{s=String(++this._lastSentReq),this._pendingEmitters.set(s,r),this._send(new m(this._workerId,s,e,t,i))},onDidRemoveLastListener:()=>{this._pendingEmitters.delete(s),this._send(new _(this._workerId,s)),s=null}});return r.event}handleMessage(e){e&&e.vsWorker&&(-1!==this._workerId&&e.vsWorker!==this._workerId||this._handleMessage(e))}createProxyToRemoteChannel(e,t){const i={get:(i,s)=>("string"!==typeof s||i[s]||(E(s)?i[s]=t=>this.listen(e,s,t):b(s)?i[s]=this.listen(e,s,void 0):36===s.charCodeAt(0)&&(i[s]=async(...i)=>(await(t?.()),this.sendMessage(e,s,i)))),i[s])};return new Proxy(Object.create(null),i)}_handleMessage(e){switch(e.type){case 1:return this._handleReplyMessage(e);case 0:return this._handleRequestMessage(e);case 2:return this._handleSubscribeEventMessage(e);case 3:return this._handleEventMessage(e);case 4:return this._handleUnsubscribeEventMessage(e)}}_handleReplyMessage(e){if(!this._pendingReplies[e.seq])return void console.warn("Got reply to unknown seq");const t=this._pendingReplies[e.seq];if(delete this._pendingReplies[e.seq],e.err){let i=e.err;return e.err.$isError&&(i=new Error,i.name=e.err.name,i.message=e.err.message,i.stack=e.err.stack),void t.reject(i)}t.resolve(e.res)}_handleRequestMessage(e){const t=e.req;this._handler.handleMessage(e.channel,e.method,e.args).then((e=>{this._send(new p(this._workerId,t,e,void 0))}),(e=>{e.detail instanceof Error&&(e.detail=(0,s.cU)(e.detail)),this._send(new p(this._workerId,t,void 0,(0,s.cU)(e)))}))}_handleSubscribeEventMessage(e){const t=e.req,i=this._handler.handleEvent(e.channel,e.eventName,e.arg)((e=>{this._send(new f(this._workerId,t,e))}));this._pendingEvents.set(t,i)}_handleEventMessage(e){this._pendingEmitters.has(e.req)?this._pendingEmitters.get(e.req).fire(e.event):console.warn("Got event for unknown req")}_handleUnsubscribeEventMessage(e){this._pendingEvents.has(e.req)?(this._pendingEvents.get(e.req).dispose(),this._pendingEvents.delete(e.req)):console.warn("Got unsubscribe for unknown req")}_send(e){const t=[];if(0===e.type)for(let i=0;i{this._protocol.handleMessage(e)}),(e=>{(0,s.dz)(e)}))),this._protocol=new v({sendMessage:(e,t)=>{this._worker.postMessage(e,t)},handleMessage:(e,t,i)=>this._handleMessage(e,t,i),handleEvent:(e,t,i)=>this._handleEvent(e,t,i)}),this._protocol.setWorkerId(this._worker.getId());let i=null;const n=globalThis.require;"undefined"!==typeof n&&"function"===typeof n.getConfig?i=n.getConfig():"undefined"!==typeof globalThis.requirejs&&(i=globalThis.requirejs.s.contexts._.config),this._onModuleLoaded=this._protocol.sendMessage(c,h,[this._worker.getId(),JSON.parse(JSON.stringify(i)),t.amdModuleId]),this.proxy=this._protocol.createProxyToRemoteChannel(c,(async()=>{await this._onModuleLoaded})),this._onModuleLoaded.catch((e=>{this._onError("Worker failed to load "+t.amdModuleId,e)}))}_handleMessage(e,t,i){const s=this._localChannels.get(e);if(!s)return Promise.reject(new Error(`Missing channel ${e} on main thread`));if("function"!==typeof s[t])return Promise.reject(new Error(`Missing method ${t} on main thread channel ${e}`));try{return Promise.resolve(s[t].apply(s,i))}catch(n){return Promise.reject(n)}}_handleEvent(e,t,i){const s=this._localChannels.get(e);if(!s)throw new Error(`Missing channel ${e} on main thread`);if(E(t)){const n=s[t].call(s,i);if("function"!==typeof n)throw new Error(`Missing dynamic event ${t} on main thread channel ${e}.`);return n}if(b(t)){const i=s[t];if("function"!==typeof i)throw new Error(`Missing event ${t} on main thread channel ${e}.`);return i}throw new Error(`Malformed event name ${t}`)}setChannel(e,t){this._localChannels.set(e,t)}_onError(e,t){console.error(e),console.info(t)}}function b(e){return"o"===e[0]&&"n"===e[1]&&l.Wv(e.charCodeAt(2))}function E(e){return/^onDynamic/.test(e)&&l.Wv(e.charCodeAt(9))}class S{constructor(e,t){this._localChannels=new Map,this._remoteChannels=new Map,this._requestHandlerFactory=t,this._requestHandler=null,this._protocol=new v({sendMessage:(t,i)=>{e(t,i)},handleMessage:(e,t,i)=>this._handleMessage(e,t,i),handleEvent:(e,t,i)=>this._handleEvent(e,t,i)})}onmessage(e){this._protocol.handleMessage(e)}_handleMessage(e,t,i){if(e===c&&t===h)return this.initialize(i[0],i[1],i[2]);const s=e===c?this._requestHandler:this._localChannels.get(e);if(!s)return Promise.reject(new Error(`Missing channel ${e} on worker thread`));if("function"!==typeof s[t])return Promise.reject(new Error(`Missing method ${t} on worker thread channel ${e}`));try{return Promise.resolve(s[t].apply(s,i))}catch(n){return Promise.reject(n)}}_handleEvent(e,t,i){const s=e===c?this._requestHandler:this._localChannels.get(e);if(!s)throw new Error(`Missing channel ${e} on worker thread`);if(E(t)){const e=s[t].call(s,i);if("function"!==typeof e)throw new Error(`Missing dynamic event ${t} on request handler.`);return e}if(b(t)){const e=s[t];if("function"!==typeof e)throw new Error(`Missing event ${t} on request handler.`);return e}throw new Error(`Malformed event name ${t}`)}getChannel(e){if(!this._remoteChannels.has(e)){const t=this._protocol.createProxyToRemoteChannel(e);this._remoteChannels.set(e,t)}return this._remoteChannels.get(e)}async initialize(e,t,s){if(this._protocol.setWorkerId(e),!this._requestHandlerFactory){t&&("undefined"!==typeof t.baseUrl&&delete t.baseUrl,"undefined"!==typeof t.paths&&"undefined"!==typeof t.paths.vs&&delete t.paths.vs,"undefined"!==typeof t.trustedTypesPolicy&&delete t.trustedTypesPolicy,t.catchError=!0,globalThis.require.config(t));{const e=o.zl.asBrowserUri(`${s}.js`).toString(!0);return i(5890)(`${e}`).then((e=>{if(this._requestHandler=e.create(this),!this._requestHandler)throw new Error("No RequestHandler!")}))}}this._requestHandler=this._requestHandlerFactory(this)}}function y(e){return new S(e,null)}},34918:(e,t,i)=>{"use strict";i.d(t,{K:()=>m});var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,l=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of l(t))c.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u={},g={},p=class e{static getOrCreate(t){return g[t]||(g[t]=new e(t)),g[t]}constructor(e){this._languageId=e,this._loadingTriggered=!1,this._lazyLoadPromise=new Promise(((e,t)=>{this._lazyLoadPromiseResolve=e,this._lazyLoadPromiseReject=t}))}load(){return this._loadingTriggered||(this._loadingTriggered=!0,u[this._languageId].loader().then((e=>this._lazyLoadPromiseResolve(e)),(e=>this._lazyLoadPromiseReject(e)))),this._lazyLoadPromise}};function m(e){const t=e.id;u[t]=e,d.languages.register(e);const i=p.getOrCreate(t);d.languages.registerTokensProviderFactory(t,{create:async()=>(await i.load()).language}),d.languages.onLanguageEncountered(t,(async()=>{const e=await i.load();d.languages.setLanguageConfiguration(t,e.conf)}))}},61562:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"abap",extensions:[".abap"],aliases:["abap","ABAP"],loader:()=>i.e(5636).then(i.bind(i,25636))})},94318:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"apex",extensions:[".cls"],aliases:["Apex","apex"],mimetypes:["text/x-apex-source","text/x-apex"],loader:()=>i.e(9872).then(i.bind(i,99872))})},23304:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"azcli",extensions:[".azcli"],aliases:["Azure CLI","azcli"],loader:()=>i.e(3534).then(i.bind(i,73534))})},59896:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"bat",extensions:[".bat",".cmd"],aliases:["Batch","bat"],loader:()=>i.e(654).then(i.bind(i,20654))})},75208:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"bicep",extensions:[".bicep"],aliases:["Bicep"],loader:()=>i.e(8014).then(i.bind(i,98014))})},51232:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"cameligo",extensions:[".mligo"],aliases:["Cameligo"],loader:()=>i.e(6374).then(i.bind(i,36374))})},77888:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"clojure",extensions:[".clj",".cljs",".cljc",".edn"],aliases:["clojure","Clojure"],loader:()=>i.e(7206).then(i.bind(i,57206))})},46686:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"coffeescript",extensions:[".coffee"],aliases:["CoffeeScript","coffeescript","coffee"],mimetypes:["text/x-coffeescript","text/coffeescript"],loader:()=>i.e(5888).then(i.bind(i,35888))})},27020:(e,t,i)=>{"use strict";var s=i(34918);(0,s.K)({id:"c",extensions:[".c",".h"],aliases:["C","c"],loader:()=>i.e(2042).then(i.bind(i,62042))}),(0,s.K)({id:"cpp",extensions:[".cpp",".cc",".cxx",".hpp",".hh",".hxx"],aliases:["C++","Cpp","cpp"],loader:()=>i.e(2042).then(i.bind(i,62042))})},15600:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"csharp",extensions:[".cs",".csx",".cake"],aliases:["C#","csharp"],loader:()=>i.e(2518).then(i.bind(i,52518))})},80200:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"csp",extensions:[".csp"],aliases:["CSP","csp"],loader:()=>i.e(5454).then(i.bind(i,55454))})},87152:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"css",extensions:[".css"],aliases:["CSS","css"],mimetypes:["text/css"],loader:()=>i.e(2742).then(i.bind(i,32742))})},60352:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"cypher",extensions:[".cypher",".cyp"],aliases:["Cypher","OpenCypher"],loader:()=>i.e(4534).then(i.bind(i,24534))})},66235:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"dart",extensions:[".dart"],aliases:["Dart","dart"],mimetypes:["text/x-dart-source","text/x-dart"],loader:()=>i.e(30).then(i.bind(i,80030))})},31474:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"dockerfile",extensions:[".dockerfile"],filenames:["Dockerfile"],aliases:["Dockerfile"],loader:()=>i.e(6012).then(i.bind(i,46012))})},84840:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"ecl",extensions:[".ecl"],aliases:["ECL","Ecl","ecl"],loader:()=>i.e(734).then(i.bind(i,734))})},17184:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"elixir",extensions:[".ex",".exs"],aliases:["Elixir","elixir","ex"],loader:()=>i.e(5382).then(i.bind(i,35382))})},74304:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"flow9",extensions:[".flow"],aliases:["Flow9","Flow","flow9","flow"],loader:()=>i.e(2854).then(i.bind(i,32854))})},74800:(e,t,i)=>{"use strict";var s=i(34918);(0,s.K)({id:"freemarker2",extensions:[".ftl",".ftlh",".ftlx"],aliases:["FreeMarker2","Apache FreeMarker2"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagAutoInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-angle.interpolation-dollar",aliases:["FreeMarker2 (Angle/Dollar)","Apache FreeMarker2 (Angle/Dollar)"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagAngleInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-bracket.interpolation-dollar",aliases:["FreeMarker2 (Bracket/Dollar)","Apache FreeMarker2 (Bracket/Dollar)"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagBracketInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-angle.interpolation-bracket",aliases:["FreeMarker2 (Angle/Bracket)","Apache FreeMarker2 (Angle/Bracket)"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagAngleInterpolationBracket))}),(0,s.K)({id:"freemarker2.tag-bracket.interpolation-bracket",aliases:["FreeMarker2 (Bracket/Bracket)","Apache FreeMarker2 (Bracket/Bracket)"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagBracketInterpolationBracket))}),(0,s.K)({id:"freemarker2.tag-auto.interpolation-dollar",aliases:["FreeMarker2 (Auto/Dollar)","Apache FreeMarker2 (Auto/Dollar)"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagAutoInterpolationDollar))}),(0,s.K)({id:"freemarker2.tag-auto.interpolation-bracket",aliases:["FreeMarker2 (Auto/Bracket)","Apache FreeMarker2 (Auto/Bracket)"],loader:()=>i.e(118).then(i.bind(i,90118)).then((e=>e.TagAutoInterpolationBracket))})},37954:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"fsharp",extensions:[".fs",".fsi",".ml",".mli",".fsx",".fsscript"],aliases:["F#","FSharp","fsharp"],loader:()=>i.e(7692).then(i.bind(i,47692))})},25922:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"go",extensions:[".go"],aliases:["Go"],loader:()=>i.e(7148).then(i.bind(i,27148))})},46648:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"graphql",extensions:[".graphql",".gql"],aliases:["GraphQL","graphql","gql"],mimetypes:["application/graphql"],loader:()=>i.e(110).then(i.bind(i,60110))})},61082:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"handlebars",extensions:[".handlebars",".hbs"],aliases:["Handlebars","handlebars","hbs"],mimetypes:["text/x-handlebars-template"],loader:()=>i.e(5252).then(i.bind(i,65252))})},19856:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"hcl",extensions:[".tf",".tfvars",".hcl"],aliases:["Terraform","tf","HCL","hcl"],loader:()=>i.e(3638).then(i.bind(i,13638))})},97884:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"html",extensions:[".html",".htm",".shtml",".xhtml",".mdoc",".jsp",".asp",".aspx",".jshtm"],aliases:["HTML","htm","html","xhtml"],mimetypes:["text/html","text/x-jshtm","text/template","text/ng-template"],loader:()=>i.e(6554).then(i.bind(i,96554))})},83488:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"ini",extensions:[".ini",".properties",".gitconfig"],filenames:["config",".gitattributes",".gitconfig",".editorconfig"],aliases:["Ini","ini"],loader:()=>i.e(4678).then(i.bind(i,54678))})},3254:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"java",extensions:[".java",".jav"],aliases:["Java","java"],mimetypes:["text/x-java-source","text/x-java"],loader:()=>i.e(9176).then(i.bind(i,99176))})},57680:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"javascript",extensions:[".js",".es6",".jsx",".mjs",".cjs"],firstLine:"^#!.*\\bnode",filenames:["jakefile"],aliases:["JavaScript","javascript","js"],mimetypes:["text/javascript"],loader:()=>i.e(2726).then(i.bind(i,2726))})},796:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"julia",extensions:[".jl"],aliases:["julia","Julia"],loader:()=>i.e(7642).then(i.bind(i,77642))})},89336:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"kotlin",extensions:[".kt",".kts"],aliases:["Kotlin","kotlin"],mimetypes:["text/x-kotlin-source","text/x-kotlin"],loader:()=>i.e(2350).then(i.bind(i,62350))})},19436:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"less",extensions:[".less"],aliases:["Less","less"],mimetypes:["text/x-less","text/less"],loader:()=>i.e(3338).then(i.bind(i,33338))})},40340:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"lexon",extensions:[".lex"],aliases:["Lexon"],loader:()=>i.e(9010).then(i.bind(i,99010))})},52894:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"liquid",extensions:[".liquid",".html.liquid"],aliases:["Liquid","liquid"],mimetypes:["application/liquid"],loader:()=>i.e(9728).then(i.bind(i,19728))})},86492:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"lua",extensions:[".lua"],aliases:["Lua","lua"],loader:()=>i.e(5050).then(i.bind(i,95050))})},73374:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"m3",extensions:[".m3",".i3",".mg",".ig"],aliases:["Modula-3","Modula3","modula3","m3"],loader:()=>i.e(9312).then(i.bind(i,79312))})},38320:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"markdown",extensions:[".md",".markdown",".mdown",".mkdn",".mkd",".mdwn",".mdtxt",".mdtext"],aliases:["Markdown","markdown"],loader:()=>i.e(3478).then(i.bind(i,73478))})},92080:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"mdx",extensions:[".mdx"],aliases:["MDX","mdx"],loader:()=>i.e(6214).then(i.bind(i,26214))})},57664:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"mips",extensions:[".s"],aliases:["MIPS","MIPS-V"],mimetypes:["text/x-mips","text/mips","text/plaintext"],loader:()=>i.e(1414).then(i.bind(i,51414))})},8868:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"msdax",extensions:[".dax",".msdax"],aliases:["DAX","MSDAX"],loader:()=>i.e(2994).then(i.bind(i,2994))})},31396:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"mysql",extensions:[],aliases:["MySQL","mysql"],loader:()=>i.e(6210).then(i.bind(i,16210))})},18544:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"objective-c",extensions:[".m"],aliases:["Objective-C"],loader:()=>i.e(7638).then(i.bind(i,97638))})},538:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"pascal",extensions:[".pas",".p",".pp"],aliases:["Pascal","pas"],mimetypes:["text/x-pascal-source","text/x-pascal"],loader:()=>i.e(132).then(i.bind(i,40132))})},25064:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"pascaligo",extensions:[".ligo"],aliases:["Pascaligo","ligo"],loader:()=>i.e(7118).then(i.bind(i,57118))})},64256:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"perl",extensions:[".pl",".pm"],aliases:["Perl","pl"],loader:()=>i.e(3158).then(i.bind(i,23158))})},32624:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"pgsql",extensions:[],aliases:["PostgreSQL","postgres","pg","postgre"],loader:()=>i.e(4582).then(i.bind(i,84582))})},97360:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"php",extensions:[".php",".php4",".php5",".phtml",".ctp"],aliases:["PHP","php"],mimetypes:["application/x-php"],loader:()=>i.e(6342).then(i.bind(i,86342))})},42776:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"pla",extensions:[".pla"],loader:()=>i.e(4542).then(i.bind(i,14542))})},97144:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"postiats",extensions:[".dats",".sats",".hats"],aliases:["ATS","ATS/Postiats"],loader:()=>i.e(9582).then(i.bind(i,49582))})},46304:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"powerquery",extensions:[".pq",".pqm"],aliases:["PQ","M","Power Query","Power Query M"],loader:()=>i.e(5542).then(i.bind(i,15542))})},58820:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"powershell",extensions:[".ps1",".psm1",".psd1"],aliases:["PowerShell","powershell","ps","ps1"],loader:()=>i.e(4818).then(i.bind(i,4818))})},82560:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"proto",extensions:[".proto"],aliases:["protobuf","Protocol Buffers"],loader:()=>i.e(902).then(i.bind(i,10902))})},74276:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"pug",extensions:[".jade",".pug"],aliases:["Pug","Jade","jade"],loader:()=>i.e(9394).then(i.bind(i,29394))})},39866:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"python",extensions:[".py",".rpy",".pyw",".cpy",".gyp",".gypi"],aliases:["Python","py"],firstLine:"^#!/.*\\bpython[0-9.-]*\\b",loader:()=>i.e(2372).then(i.bind(i,22372))})},73020:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"qsharp",extensions:[".qs"],aliases:["Q#","qsharp"],loader:()=>i.e(5866).then(i.bind(i,5866))})},71316:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"r",extensions:[".r",".rhistory",".rmd",".rprofile",".rt"],aliases:["R","r"],loader:()=>i.e(6658).then(i.bind(i,86658))})},70492:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"razor",extensions:[".cshtml"],aliases:["Razor","razor"],mimetypes:["text/x-cshtml"],loader:()=>i.e(8986).then(i.bind(i,58986))})},50848:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"redis",extensions:[".redis"],aliases:["redis"],loader:()=>i.e(4662).then(i.bind(i,24662))})},59520:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"redshift",extensions:[],aliases:["Redshift","redshift"],loader:()=>i.e(3702).then(i.bind(i,23702))})},46576:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"restructuredtext",extensions:[".rst"],aliases:["reStructuredText","restructuredtext"],loader:()=>i.e(2182).then(i.bind(i,42182))})},49150:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"ruby",extensions:[".rb",".rbx",".rjs",".gemspec",".pp"],filenames:["rakefile","Gemfile"],aliases:["Ruby","rb"],loader:()=>i.e(2016).then(i.bind(i,92016))})},33358:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"rust",extensions:[".rs",".rlib"],aliases:["Rust","rust"],loader:()=>i.e(3648).then(i.bind(i,3648))})},96716:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sb",extensions:[".sb"],aliases:["Small Basic","sb"],loader:()=>i.e(7946).then(i.bind(i,57946))})},28304:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"scala",extensions:[".scala",".sc",".sbt"],aliases:["Scala","scala","SBT","Sbt","sbt","Dotty","dotty"],mimetypes:["text/x-scala-source","text/x-scala","text/x-sbt","text/x-dotty"],loader:()=>i.e(3977).then(i.bind(i,56358))})},14720:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"scheme",extensions:[".scm",".ss",".sch",".rkt"],aliases:["scheme","Scheme"],loader:()=>i.e(7574).then(i.bind(i,67574))})},27734:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"scss",extensions:[".scss"],aliases:["Sass","sass","scss"],mimetypes:["text/x-scss","text/scss"],loader:()=>i.e(3048).then(i.bind(i,3048))})},2068:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"shell",extensions:[".sh",".bash"],aliases:["Shell","sh"],loader:()=>i.e(9842).then(i.bind(i,79842))})},71468:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sol",extensions:[".sol"],aliases:["sol","solidity","Solidity"],loader:()=>i.e(8234).then(i.bind(i,98234))})},15482:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"aes",extensions:[".aes"],aliases:["aes","sophia","Sophia"],loader:()=>i.e(5988).then(i.bind(i,65988))})},42572:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sparql",extensions:[".rq"],aliases:["sparql","SPARQL"],loader:()=>i.e(957).then(i.bind(i,53338))})},77668:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"sql",extensions:[".sql"],aliases:["SQL"],loader:()=>i.e(9778).then(i.bind(i,49778))})},36e3:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"st",extensions:[".st",".iecst",".iecplc",".lc3lib",".TcPOU",".TcDUT",".TcGVL",".TcIO"],aliases:["StructuredText","scl","stl"],loader:()=>i.e(1321).then(i.bind(i,43702))})},10072:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"swift",aliases:["Swift","swift"],extensions:[".swift"],mimetypes:["text/swift"],loader:()=>i.e(1278).then(i.bind(i,11278))})},48448:(e,t,i)=>{"use strict";var s=i(34918);(0,s.K)({id:"systemverilog",extensions:[".sv",".svh"],aliases:["SV","sv","SystemVerilog","systemverilog"],loader:()=>i.e(6262).then(i.bind(i,66262))}),(0,s.K)({id:"verilog",extensions:[".v",".vh"],aliases:["V","v","Verilog","verilog"],loader:()=>i.e(6262).then(i.bind(i,66262))})},51376:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"tcl",extensions:[".tcl"],aliases:["tcl","Tcl","tcltk","TclTk","tcl/tk","Tcl/Tk"],loader:()=>i.e(246).then(i.bind(i,10246))})},61764:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"twig",extensions:[".twig"],aliases:["Twig","twig"],mimetypes:["text/x-twig"],loader:()=>i.e(2162).then(i.bind(i,2162))})},85872:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"typescript",extensions:[".ts",".tsx",".cts",".mts"],aliases:["TypeScript","ts","typescript"],mimetypes:["text/typescript"],loader:()=>i.e(1606).then(i.bind(i,1606))})},42144:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"typespec",extensions:[".tsp"],aliases:["TypeSpec"],loader:()=>i.e(1094).then(i.bind(i,51094))})},22362:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"vb",extensions:[".vb"],aliases:["Visual Basic","vb"],loader:()=>i.e(9748).then(i.bind(i,59748))})},98408:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"wgsl",extensions:[".wgsl"],aliases:["WebGPU Shading Language","WGSL","wgsl"],loader:()=>i.e(3822).then(i.bind(i,33822))})},61472:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"xml",extensions:[".xml",".xsd",".dtd",".ascx",".csproj",".config",".props",".targets",".wxi",".wxl",".wxs",".xaml",".svg",".svgz",".opf",".xslt",".xsl"],firstLine:"(\\<\\?xml.*)|(\\i.e(7718).then(i.bind(i,77718))})},50576:(e,t,i)=>{"use strict";(0,i(34918).K)({id:"yaml",extensions:[".yaml",".yml"],aliases:["YAML","yaml","YML","yml"],mimetypes:["application/x-yaml","text/x-yaml"],loader:()=>i.e(4870).then(i.bind(i,84870))})},73157:(e,t,i)=>{"use strict";i.d(t,{M:()=>n});var s=i(55275);function n(e,t){e instanceof s.D?(e.setFontFamily(t.getMassagedFontFamily()),e.setFontWeight(t.fontWeight),e.setFontSize(t.fontSize),e.setFontFeatureSettings(t.fontFeatureSettings),e.setFontVariationSettings(t.fontVariationSettings),e.setLineHeight(t.lineHeight),e.setLetterSpacing(t.letterSpacing)):(e.style.fontFamily=t.getMassagedFontFamily(),e.style.fontWeight=t.fontWeight,e.style.fontSize=t.fontSize+"px",e.style.fontFeatureSettings=t.fontFeatureSettings,e.style.fontVariationSettings=t.fontVariationSettings,e.style.lineHeight=t.lineHeight+"px",e.style.letterSpacing=t.letterSpacing+"px")}},4983:(e,t,i)=>{"use strict";i.d(t,{u:()=>o});var s=i(5662),n=i(41234),r=i(8597);class o extends s.jG{constructor(e,t){super(),this._onDidChange=this._register(new n.vl),this.onDidChange=this._onDidChange.event,this._referenceDomElement=e,this._width=-1,this._height=-1,this._resizeObserver=null,this.measureReferenceDomElement(!1,t)}dispose(){this.stopObserving(),super.dispose()}getWidth(){return this._width}getHeight(){return this._height}startObserving(){if(!this._resizeObserver&&this._referenceDomElement){let e=null;const t=()=>{e?this.observe({width:e.width,height:e.height}):this.observe()};let i=!1,s=!1;const n=()=>{if(i&&!s)try{i=!1,s=!0,t()}finally{(0,r.PG)((0,r.zk)(this._referenceDomElement),(()=>{s=!1,n()}))}};this._resizeObserver=new ResizeObserver((t=>{e=t&&t[0]&&t[0].contentRect?{width:t[0].contentRect.width,height:t[0].contentRect.height}:null,i=!0,n()})),this._resizeObserver.observe(this._referenceDomElement)}}stopObserving(){this._resizeObserver&&(this._resizeObserver.disconnect(),this._resizeObserver=null)}observe(e){this.measureReferenceDomElement(!0,e)}measureReferenceDomElement(e,t){let i=0,s=0;t?(i=t.width,s=t.height):this._referenceDomElement&&(i=this._referenceDomElement.clientWidth,s=this._referenceDomElement.clientHeight),i=Math.max(5,i),s=Math.max(5,s),this._width===i&&this._height===s||(this._width=i,this._height=s,e&&this._onDidChange.fire())}}},28433:(e,t,i)=>{"use strict";i.d(t,{T:()=>p});var s=i(8597),n=i(94106),r=i(41234),o=i(5662),a=i(73157);class l{constructor(e,t){this.chr=e,this.type=t,this.width=0}fulfill(e){this.width=e}}class c{constructor(e,t){this._bareFontInfo=e,this._requests=t,this._container=null,this._testElements=null}read(e){this._createDomElements(),e.document.body.appendChild(this._container),this._readFromDomElements(),this._container?.remove(),this._container=null,this._testElements=null}_createDomElements(){const e=document.createElement("div");e.style.position="absolute",e.style.top="-50000px",e.style.width="50000px";const t=document.createElement("div");(0,a.M)(t,this._bareFontInfo),e.appendChild(t);const i=document.createElement("div");(0,a.M)(i,this._bareFontInfo),i.style.fontWeight="bold",e.appendChild(i);const s=document.createElement("div");(0,a.M)(s,this._bareFontInfo),s.style.fontStyle="italic",e.appendChild(s);const n=[];for(const r of this._requests){let e;0===r.type&&(e=t),2===r.type&&(e=i),1===r.type&&(e=s),e.appendChild(document.createElement("br"));const o=document.createElement("span");c._render(o,r),e.appendChild(o),n.push(o)}this._container=e,this._testElements=n}static _render(e,t){if(" "===t.chr){let t="\xa0";for(let e=0;e<8;e++)t+=t;e.innerText=t}else{let i=t.chr;for(let e=0;e<8;e++)i+=i;e.textContent=i}}_readFromDomElements(){for(let e=0,t=this._requests.length;e{this._evictUntrustedReadingsTimeout=-1,this._evictUntrustedReadings(e)}),5e3))}_evictUntrustedReadings(e){const t=this._ensureCache(e),i=t.getValues();let s=!1;for(const n of i)n.isTrusted||(s=!0,t.remove(n));s&&this._onDidChange.fire()}readFontInfo(e,t){const i=this._ensureCache(e);if(!i.has(t)){let i=this._actualReadFontInfo(e,t);(i.typicalHalfwidthCharacterWidth<=2||i.typicalFullwidthCharacterWidth<=2||i.spaceWidth<=2||i.maxDigitWidth<=2)&&(i=new d.YJ({pixelRatio:n.c.getInstance(e).value,fontFamily:i.fontFamily,fontWeight:i.fontWeight,fontSize:i.fontSize,fontFeatureSettings:i.fontFeatureSettings,fontVariationSettings:i.fontVariationSettings,lineHeight:i.lineHeight,letterSpacing:i.letterSpacing,isMonospace:i.isMonospace,typicalHalfwidthCharacterWidth:Math.max(i.typicalHalfwidthCharacterWidth,5),typicalFullwidthCharacterWidth:Math.max(i.typicalFullwidthCharacterWidth,5),canUseHalfwidthRightwardsArrow:i.canUseHalfwidthRightwardsArrow,spaceWidth:Math.max(i.spaceWidth,5),middotWidth:Math.max(i.middotWidth,5),wsmiddotWidth:Math.max(i.wsmiddotWidth,5),maxDigitWidth:Math.max(i.maxDigitWidth,5)},!1)),this._writeToCache(e,t,i)}return i.get(t)}_createRequest(e,t,i,s){const n=new l(e,t);return i.push(n),s?.push(n),n}_actualReadFontInfo(e,t){const i=[],s=[],r=this._createRequest("n",0,i,s),o=this._createRequest("\uff4d",0,i,null),a=this._createRequest(" ",0,i,s),l=this._createRequest("0",0,i,s),u=this._createRequest("1",0,i,s),g=this._createRequest("2",0,i,s),p=this._createRequest("3",0,i,s),m=this._createRequest("4",0,i,s),f=this._createRequest("5",0,i,s),_=this._createRequest("6",0,i,s),v=this._createRequest("7",0,i,s),C=this._createRequest("8",0,i,s),b=this._createRequest("9",0,i,s),E=this._createRequest("\u2192",0,i,s),S=this._createRequest("\uffeb",0,i,null),y=this._createRequest("\xb7",0,i,s),w=this._createRequest(String.fromCharCode(11825),0,i,null),L="|/-_ilm%";for(let n=0,c=8;n.001){T=!1;break}}let k=!0;return T&&S.width!==x&&(k=!1),S.width>E.width&&(k=!1),new d.YJ({pixelRatio:n.c.getInstance(e).value,fontFamily:t.fontFamily,fontWeight:t.fontWeight,fontSize:t.fontSize,fontFeatureSettings:t.fontFeatureSettings,fontVariationSettings:t.fontVariationSettings,lineHeight:t.lineHeight,letterSpacing:t.letterSpacing,isMonospace:T,typicalHalfwidthCharacterWidth:r.width,typicalFullwidthCharacterWidth:o.width,canUseHalfwidthRightwardsArrow:k,spaceWidth:a.width,middotWidth:y.width,wsmiddotWidth:w.width,maxDigitWidth:R},!0)}}class g{constructor(){this._keys=Object.create(null),this._values=Object.create(null)}has(e){const t=e.getId();return!!this._values[t]}get(e){const t=e.getId();return this._values[t]}put(e,t){const i=e.getId();this._keys[i]=e,this._values[i]=t}remove(e){const t=e.getId();delete this._keys[t],delete this._values[t]}getValues(){return Object.keys(this._keys).map((e=>this._values[e]))}}const p=new u},77163:(e,t,i)=>{"use strict";i.d(t,{M:()=>n});var s=i(41234);const n=new class{constructor(){this._tabFocus=!1,this._onDidChangeTabFocus=new s.vl,this.onDidChangeTabFocus=this._onDidChangeTabFocus.event}getTabFocusMode(){return this._tabFocus}setTabFocusMode(e){this._tabFocus=e,this._onDidChangeTabFocus.fire(this._tabFocus)}}},68792:(e,t,i)=>{"use strict";i.d(t,{$D:()=>s,Eq:()=>b,M0:()=>L,Mz:()=>w,No:()=>y,bs:()=>E});var s,n=i(60413),r=i(8597),o=i(56245),a=i(72962),l=i(5239),c=i(90766),h=i(41234),d=i(5662),u=i(44320),g=i(91508),p=i(69785),m=i(75326),f=i(253),_=i(18801),v=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},C=function(e,t){return function(i,s){t(i,s,e)}};!function(e){e.Tap="-monaco-textarea-synthetic-tap"}(s||(s={}));const b={forceCopyWithSyntaxHighlighting:!1};class E{static{this.INSTANCE=new E}constructor(){this._lastState=null}set(e,t){this._lastState={lastCopiedValue:e,data:t}}get(e){return this._lastState&&this._lastState.lastCopiedValue===e?this._lastState.data:(this._lastState=null,null)}}class S{constructor(){this._lastTypeTextLength=0}handleCompositionUpdate(e){const t={text:e=e||"",replacePrevCharCnt:this._lastTypeTextLength,replaceNextCharCnt:0,positionDelta:0};return this._lastTypeTextLength=e.length,t}}let y=class extends d.jG{get textAreaState(){return this._textAreaState}constructor(e,t,i,s,n,r){super(),this._host=e,this._textArea=t,this._OS=i,this._browser=s,this._accessibilityService=n,this._logService=r,this._onFocus=this._register(new h.vl),this.onFocus=this._onFocus.event,this._onBlur=this._register(new h.vl),this.onBlur=this._onBlur.event,this._onKeyDown=this._register(new h.vl),this.onKeyDown=this._onKeyDown.event,this._onKeyUp=this._register(new h.vl),this.onKeyUp=this._onKeyUp.event,this._onCut=this._register(new h.vl),this.onCut=this._onCut.event,this._onPaste=this._register(new h.vl),this.onPaste=this._onPaste.event,this._onType=this._register(new h.vl),this.onType=this._onType.event,this._onCompositionStart=this._register(new h.vl),this.onCompositionStart=this._onCompositionStart.event,this._onCompositionUpdate=this._register(new h.vl),this.onCompositionUpdate=this._onCompositionUpdate.event,this._onCompositionEnd=this._register(new h.vl),this.onCompositionEnd=this._onCompositionEnd.event,this._onSelectionChangeRequest=this._register(new h.vl),this.onSelectionChangeRequest=this._onSelectionChangeRequest.event,this._asyncFocusGainWriteScreenReaderContent=this._register(new d.HE),this._asyncTriggerCut=this._register(new c.uC((()=>this._onCut.fire()),0)),this._textAreaState=p._O.EMPTY,this._selectionChangeListener=null,this._accessibilityService.isScreenReaderOptimized()&&this.writeNativeTextAreaContent("ctor"),this._register(h.Jh.runAndSubscribe(this._accessibilityService.onDidChangeScreenReaderOptimized,(()=>{this._accessibilityService.isScreenReaderOptimized()&&!this._asyncFocusGainWriteScreenReaderContent.value?this._asyncFocusGainWriteScreenReaderContent.value=this._register(new c.uC((()=>this.writeNativeTextAreaContent("asyncFocusGain")),0)):this._asyncFocusGainWriteScreenReaderContent.clear()}))),this._hasFocus=!1,this._currentComposition=null;let o=null;this._register(this._textArea.onKeyDown((e=>{const t=new a.Z(e);(114===t.keyCode||this._currentComposition&&1===t.keyCode)&&t.stopPropagation(),t.equals(9)&&t.preventDefault(),o=t,this._onKeyDown.fire(t)}))),this._register(this._textArea.onKeyUp((e=>{const t=new a.Z(e);this._onKeyUp.fire(t)}))),this._register(this._textArea.onCompositionStart((e=>{p.Hf&&console.log("[compositionstart]",e);const t=new S;if(this._currentComposition)this._currentComposition=t;else{if(this._currentComposition=t,2===this._OS&&o&&o.equals(114)&&this._textAreaState.selectionStart===this._textAreaState.selectionEnd&&this._textAreaState.selectionStart>0&&this._textAreaState.value.substr(this._textAreaState.selectionStart-1,1)===e.data&&("ArrowRight"===o.code||"ArrowLeft"===o.code))return p.Hf&&console.log("[compositionstart] Handling long press case on macOS + arrow key",e),t.handleCompositionUpdate("x"),void this._onCompositionStart.fire({data:e.data});this._browser.isAndroid,this._onCompositionStart.fire({data:e.data})}}))),this._register(this._textArea.onCompositionUpdate((e=>{p.Hf&&console.log("[compositionupdate]",e);const t=this._currentComposition;if(!t)return;if(this._browser.isAndroid){const t=p._O.readFromTextArea(this._textArea,this._textAreaState),i=p._O.deduceAndroidCompositionInput(this._textAreaState,t);return this._textAreaState=t,this._onType.fire(i),void this._onCompositionUpdate.fire(e)}const i=t.handleCompositionUpdate(e.data);this._textAreaState=p._O.readFromTextArea(this._textArea,this._textAreaState),this._onType.fire(i),this._onCompositionUpdate.fire(e)}))),this._register(this._textArea.onCompositionEnd((e=>{p.Hf&&console.log("[compositionend]",e);const t=this._currentComposition;if(!t)return;if(this._currentComposition=null,this._browser.isAndroid){const e=p._O.readFromTextArea(this._textArea,this._textAreaState),t=p._O.deduceAndroidCompositionInput(this._textAreaState,e);return this._textAreaState=e,this._onType.fire(t),void this._onCompositionEnd.fire()}const i=t.handleCompositionUpdate(e.data);this._textAreaState=p._O.readFromTextArea(this._textArea,this._textAreaState),this._onType.fire(i),this._onCompositionEnd.fire()}))),this._register(this._textArea.onInput((e=>{if(p.Hf&&console.log("[input]",e),this._textArea.setIgnoreSelectionChangeTime("received input event"),this._currentComposition)return;const t=p._O.readFromTextArea(this._textArea,this._textAreaState),i=p._O.deduceInput(this._textAreaState,t,2===this._OS);(0!==i.replacePrevCharCnt||1!==i.text.length||!g.pc(i.text.charCodeAt(0))&&127!==i.text.charCodeAt(0))&&(this._textAreaState=t,""===i.text&&0===i.replacePrevCharCnt&&0===i.replaceNextCharCnt&&0===i.positionDelta||this._onType.fire(i))}))),this._register(this._textArea.onCut((e=>{this._textArea.setIgnoreSelectionChangeTime("received cut event"),this._ensureClipboardGetsEditorSelection(e),this._asyncTriggerCut.schedule()}))),this._register(this._textArea.onCopy((e=>{this._ensureClipboardGetsEditorSelection(e)}))),this._register(this._textArea.onPaste((e=>{if(this._textArea.setIgnoreSelectionChangeTime("received paste event"),e.preventDefault(),!e.clipboardData)return;let[t,i]=w.getTextData(e.clipboardData);t&&(i=i||E.INSTANCE.get(t),this._onPaste.fire({text:t,metadata:i}))}))),this._register(this._textArea.onFocus((()=>{const e=this._hasFocus;this._setHasFocus(!0),this._accessibilityService.isScreenReaderOptimized()&&this._browser.isSafari&&!e&&this._hasFocus&&(this._asyncFocusGainWriteScreenReaderContent.value||(this._asyncFocusGainWriteScreenReaderContent.value=new c.uC((()=>this.writeNativeTextAreaContent("asyncFocusGain")),0)),this._asyncFocusGainWriteScreenReaderContent.value.schedule())}))),this._register(this._textArea.onBlur((()=>{this._currentComposition&&(this._currentComposition=null,this.writeNativeTextAreaContent("blurWithoutCompositionEnd"),this._onCompositionEnd.fire()),this._setHasFocus(!1)}))),this._register(this._textArea.onSyntheticTap((()=>{this._browser.isAndroid&&this._currentComposition&&(this._currentComposition=null,this.writeNativeTextAreaContent("tapWithoutCompositionEnd"),this._onCompositionEnd.fire())})))}_installSelectionChangeListener(){let e=0;return r.ko(this._textArea.ownerDocument,"selectionchange",(t=>{if(l.p.onSelectionChange(),!this._hasFocus)return;if(this._currentComposition)return;if(!this._browser.isChrome)return;const i=Date.now(),s=i-e;if(e=i,s<5)return;const n=i-this._textArea.getIgnoreSelectionChangeTime();if(this._textArea.resetSelectionChangeTime(),n<100)return;if(!this._textAreaState.selection)return;const r=this._textArea.getValue();if(this._textAreaState.value!==r)return;const o=this._textArea.getSelectionStart(),a=this._textArea.getSelectionEnd();if(this._textAreaState.selectionStart===o&&this._textAreaState.selectionEnd===a)return;const c=this._textAreaState.deduceEditorPosition(o),h=this._host.deduceModelPosition(c[0],c[1],c[2]),d=this._textAreaState.deduceEditorPosition(a),u=this._host.deduceModelPosition(d[0],d[1],d[2]),g=new m.L(h.lineNumber,h.column,u.lineNumber,u.column);this._onSelectionChangeRequest.fire(g)}))}dispose(){super.dispose(),this._selectionChangeListener&&(this._selectionChangeListener.dispose(),this._selectionChangeListener=null)}focusTextArea(){this._setHasFocus(!0),this.refreshFocusState()}isFocused(){return this._hasFocus}refreshFocusState(){this._setHasFocus(this._textArea.hasFocus())}_setHasFocus(e){this._hasFocus!==e&&(this._hasFocus=e,this._selectionChangeListener&&(this._selectionChangeListener.dispose(),this._selectionChangeListener=null),this._hasFocus&&(this._selectionChangeListener=this._installSelectionChangeListener()),this._hasFocus&&this.writeNativeTextAreaContent("focusgain"),this._hasFocus?this._onFocus.fire():this._onBlur.fire())}_setAndWriteTextAreaState(e,t){this._hasFocus||(t=t.collapseSelection()),t.writeToTextArea(e,this._textArea,this._hasFocus),this._textAreaState=t}writeNativeTextAreaContent(e){!this._accessibilityService.isScreenReaderOptimized()&&"render"===e||this._currentComposition||(this._logService.trace(`writeTextAreaState(reason: ${e})`),this._setAndWriteTextAreaState(e,this._host.getScreenReaderContent()))}_ensureClipboardGetsEditorSelection(e){const t=this._host.getDataToCopy(),i={version:1,isFromEmptySelection:t.isFromEmptySelection,multicursorText:t.multicursorText,mode:t.mode};E.INSTANCE.set(this._browser.isFirefox?t.text.replace(/\r\n/g,"\n"):t.text,i),e.preventDefault(),e.clipboardData&&w.setTextData(e.clipboardData,t.text,t.html,i)}};y=v([C(4,f.j),C(5,_.rr)],y);const w={getTextData(e){const t=e.getData(u.K.text);let i=null;const s=e.getData("vscode-editor-data");if("string"===typeof s)try{i=JSON.parse(s),1!==i.version&&(i=null)}catch(n){}if(0===t.length&&null===i&&e.files.length>0){return[Array.prototype.slice.call(e.files,0).map((e=>e.name)).join("\n"),null]}return[t,i]},setTextData(e,t,i,s){e.setData(u.K.text,t),"string"===typeof i&&e.setData("text/html",i),e.setData("vscode-editor-data",JSON.stringify(s))}};class L extends d.jG{get ownerDocument(){return this._actual.ownerDocument}constructor(e){super(),this._actual=e,this.onKeyDown=this._register(new o.f(this._actual,"keydown")).event,this.onKeyUp=this._register(new o.f(this._actual,"keyup")).event,this.onCompositionStart=this._register(new o.f(this._actual,"compositionstart")).event,this.onCompositionUpdate=this._register(new o.f(this._actual,"compositionupdate")).event,this.onCompositionEnd=this._register(new o.f(this._actual,"compositionend")).event,this.onBeforeInput=this._register(new o.f(this._actual,"beforeinput")).event,this.onInput=this._register(new o.f(this._actual,"input")).event,this.onCut=this._register(new o.f(this._actual,"cut")).event,this.onCopy=this._register(new o.f(this._actual,"copy")).event,this.onPaste=this._register(new o.f(this._actual,"paste")).event,this.onFocus=this._register(new o.f(this._actual,"focus")).event,this.onBlur=this._register(new o.f(this._actual,"blur")).event,this._onSyntheticTap=this._register(new h.vl),this.onSyntheticTap=this._onSyntheticTap.event,this._ignoreSelectionChangeTime=0,this._register(this.onKeyDown((()=>l.p.onKeyDown()))),this._register(this.onBeforeInput((()=>l.p.onBeforeInput()))),this._register(this.onInput((()=>l.p.onInput()))),this._register(this.onKeyUp((()=>l.p.onKeyUp()))),this._register(r.ko(this._actual,s.Tap,(()=>this._onSyntheticTap.fire())))}hasFocus(){const e=r.jG(this._actual);return e?e.activeElement===this._actual:!!this._actual.isConnected&&r.bq()===this._actual}setIgnoreSelectionChangeTime(e){this._ignoreSelectionChangeTime=Date.now()}getIgnoreSelectionChangeTime(){return this._ignoreSelectionChangeTime}resetSelectionChangeTime(){this._ignoreSelectionChangeTime=0}getValue(){return this._actual.value}setValue(e,t){const i=this._actual;i.value!==t&&(this.setIgnoreSelectionChangeTime("setValue"),i.value=t)}getSelectionStart(){return"backward"===this._actual.selectionDirection?this._actual.selectionEnd:this._actual.selectionStart}getSelectionEnd(){return"backward"===this._actual.selectionDirection?this._actual.selectionStart:this._actual.selectionEnd}setSelectionRange(e,t,i){const s=this._actual;let o=null;const a=r.jG(s);o=a?a.activeElement:r.bq();const l=r.zk(o),c=o===s,h=s.selectionStart,d=s.selectionEnd;if(c&&h===t&&d===i)n.gm&&l.parent!==l&&s.focus();else{if(c)return this.setIgnoreSelectionChangeTime("setSelectionRange"),s.setSelectionRange(t,i),void(n.gm&&l.parent!==l&&s.focus());try{const e=r.zK(s);this.setIgnoreSelectionChangeTime("setSelectionRange"),s.focus(),s.setSelectionRange(t,i),r.wk(s,e)}catch(u){}}}}},69785:(e,t,i)=>{"use strict";i.d(t,{Al:()=>a,Hf:()=>r,_O:()=>o});var s=i(91508),n=i(36677);const r=!1;class o{static{this.EMPTY=new o("",0,0,null,void 0)}constructor(e,t,i,s,n){this.value=e,this.selectionStart=t,this.selectionEnd=i,this.selection=s,this.newlineCountBeforeSelection=n}toString(){return`[ <${this.value}>, selectionStart: ${this.selectionStart}, selectionEnd: ${this.selectionEnd}]`}static readFromTextArea(e,t){const i=e.getValue(),s=e.getSelectionStart(),n=e.getSelectionEnd();let r;if(t){i.substring(0,s)===t.value.substring(0,t.selectionStart)&&(r=t.newlineCountBeforeSelection)}return new o(i,s,n,null,r)}collapseSelection(){return this.selectionStart===this.value.length?this:new o(this.value,this.value.length,this.value.length,null,void 0)}writeToTextArea(e,t,i){r&&console.log(`writeToTextArea ${e}: ${this.toString()}`),t.setValue(e,this.value),i&&t.setSelectionRange(e,this.selectionStart,this.selectionEnd)}deduceEditorPosition(e){if(e<=this.selectionStart){const t=this.value.substring(e,this.selectionStart);return this._finishDeduceEditorPosition(this.selection?.getStartPosition()??null,t,-1)}if(e>=this.selectionEnd){const t=this.value.substring(this.selectionEnd,e);return this._finishDeduceEditorPosition(this.selection?.getEndPosition()??null,t,1)}const t=this.value.substring(this.selectionStart,e);if(-1===t.indexOf(String.fromCharCode(8230)))return this._finishDeduceEditorPosition(this.selection?.getStartPosition()??null,t,1);const i=this.value.substring(e,this.selectionEnd);return this._finishDeduceEditorPosition(this.selection?.getEndPosition()??null,i,-1)}_finishDeduceEditorPosition(e,t,i){let s=0,n=-1;for(;-1!==(n=t.indexOf("\n",n+1));)s++;return[e,i*t.length,s]}static deduceInput(e,t,i){if(!e)return{text:"",replacePrevCharCnt:0,replaceNextCharCnt:0,positionDelta:0};r&&(console.log("------------------------deduceInput"),console.log(`PREVIOUS STATE: ${e.toString()}`),console.log(`CURRENT STATE: ${t.toString()}`));const n=Math.min(s.Qp(e.value,t.value),e.selectionStart,t.selectionStart),o=Math.min(s.Vi(e.value,t.value),e.value.length-e.selectionEnd,t.value.length-t.selectionEnd),a=e.value.substring(n,e.value.length-o),l=t.value.substring(n,t.value.length-o),c=e.selectionStart-n,h=e.selectionEnd-n,d=t.selectionStart-n,u=t.selectionEnd-n;if(r&&(console.log(`AFTER DIFFING PREVIOUS STATE: <${a}>, selectionStart: ${c}, selectionEnd: ${h}`),console.log(`AFTER DIFFING CURRENT STATE: <${l}>, selectionStart: ${d}, selectionEnd: ${u}`)),d===u){const t=e.selectionStart-n;return r&&console.log(`REMOVE PREVIOUS: ${t} chars`),{text:l,replacePrevCharCnt:t,replaceNextCharCnt:0,positionDelta:0}}return{text:l,replacePrevCharCnt:h-c,replaceNextCharCnt:0,positionDelta:0}}static deduceAndroidCompositionInput(e,t){if(!e)return{text:"",replacePrevCharCnt:0,replaceNextCharCnt:0,positionDelta:0};if(r&&(console.log("------------------------deduceAndroidCompositionInput"),console.log(`PREVIOUS STATE: ${e.toString()}`),console.log(`CURRENT STATE: ${t.toString()}`)),e.value===t.value)return{text:"",replacePrevCharCnt:0,replaceNextCharCnt:0,positionDelta:t.selectionEnd-e.selectionEnd};const i=Math.min(s.Qp(e.value,t.value),e.selectionEnd),n=Math.min(s.Vi(e.value,t.value),e.value.length-e.selectionEnd),o=e.value.substring(i,e.value.length-n),a=t.value.substring(i,t.value.length-n),l=e.selectionStart-i,c=e.selectionEnd-i,h=t.selectionStart-i,d=t.selectionEnd-i;return r&&(console.log(`AFTER DIFFING PREVIOUS STATE: <${o}>, selectionStart: ${l}, selectionEnd: ${c}`),console.log(`AFTER DIFFING CURRENT STATE: <${a}>, selectionStart: ${h}, selectionEnd: ${d}`)),{text:a,replacePrevCharCnt:c,replaceNextCharCnt:o.length-c,positionDelta:d-a.length}}}class a{static _getPageOfLine(e,t){return Math.floor((e-1)/t)}static _getRangeForPage(e,t){const i=e*t,s=i+1,r=i+t;return new n.Q(s,1,r+1,1)}static fromEditorSelection(e,t,i,s){const r=500,l=a._getPageOfLine(t.startLineNumber,i),c=a._getRangeForPage(l,i),h=a._getPageOfLine(t.endLineNumber,i),d=a._getRangeForPage(h,i);let u=c.intersectRanges(new n.Q(1,1,t.startLineNumber,t.startColumn));if(s&&e.getValueLengthInRange(u,1)>r){const t=e.modifyPosition(u.getEndPosition(),-500);u=n.Q.fromPositions(t,u.getEndPosition())}const g=e.getValueInRange(u,1),p=e.getLineCount(),m=e.getLineMaxColumn(p);let f=d.intersectRanges(new n.Q(t.endLineNumber,t.endColumn,p,m));if(s&&e.getValueLengthInRange(f,1)>r){const t=e.modifyPosition(f.getStartPosition(),r);f=n.Q.fromPositions(f.getStartPosition(),t)}const _=e.getValueInRange(f,1);let v;if(l===h||l+1===h)v=e.getValueInRange(t,1);else{const i=c.intersectRanges(t),s=d.intersectRanges(t);v=e.getValueInRange(i,1)+String.fromCharCode(8230)+e.getValueInRange(s,1)}return s&&v.length>1e3&&(v=v.substring(0,r)+String.fromCharCode(8230)+v.substring(v.length-r,v.length)),new o(g+v+_,g.length,g.length+v.length,t,u.endLineNumber-u.startLineNumber)}}},36999:(e,t,i)=>{"use strict";i.d(t,{Yh:()=>k,QM:()=>w});var s=i(78209),n=i(60413),r=i(631),o=i(11007),a=i(31450),l=i(80301),c=i(32799),h=i(83069),d=i(36677);class u{static columnSelect(e,t,i,s,n,r){const o=Math.abs(n-i)+1,a=i>n,l=s>r,u=sr)continue;if(_s)continue;if(f0&&s--,u.columnSelect(e,t,i.fromViewLineNumber,i.fromViewVisualColumn,i.toViewLineNumber,s)}static columnSelectRight(e,t,i){let s=0;const n=Math.min(i.fromViewLineNumber,i.toViewLineNumber),r=Math.max(i.fromViewLineNumber,i.toViewLineNumber);for(let a=n;a<=r;a++){const i=t.getLineMaxColumn(a),n=e.visibleColumnFromColumn(t,new h.y(a,i));s=Math.max(s,n)}let o=i.toViewVisualColumn;return o{const i=e.get(l.T).getFocusedCodeEditor();return!(!i||!i.hasTextFocus())&&this._runEditorCommand(e,i,t)})),e.addImplementation(1e3,"generic-dom-input-textarea",((e,t)=>{const i=(0,C.bq)();return!!(i&&["input","textarea"].indexOf(i.tagName.toLowerCase())>=0)&&(this.runDOMCommand(i),!0)})),e.addImplementation(0,"generic-dom",((e,t)=>{const i=e.get(l.T).getActiveCodeEditor();return!!i&&(i.focus(),this._runEditorCommand(e,i,t))}))}_runEditorCommand(e,t,i){const s=this.runEditorCommand(e,t,i);return s||!0}}!function(e){class t extends E{constructor(e){super(e),this._inSelectionMode=e.inSelectionMode}runCoreEditorCommand(e,t){if(!t.position)return;e.model.pushStackElement();e.setCursorStates(t.source,3,[p.c.moveTo(e,e.getPrimaryCursorState(),this._inSelectionMode,t.position,t.viewPosition)])&&2!==t.revealType&&e.revealAllCursors(t.source,!0,!0)}}e.MoveTo=(0,a.E_)(new t({id:"_moveTo",inSelectionMode:!1,precondition:void 0})),e.MoveToSelect=(0,a.E_)(new t({id:"_moveToSelect",inSelectionMode:!0,precondition:void 0}));class i extends E{runCoreEditorCommand(e,t){e.model.pushStackElement();const i=this._getColumnSelectResult(e,e.getPrimaryCursorState(),e.getCursorColumnSelectData(),t);null!==i&&(e.setCursorStates(t.source,3,i.viewStates.map((e=>c.MF.fromViewState(e)))),e.setCursorColumnSelectData({isReal:!0,fromViewLineNumber:i.fromLineNumber,fromViewVisualColumn:i.fromVisualColumn,toViewLineNumber:i.toLineNumber,toViewVisualColumn:i.toVisualColumn}),i.reversed?e.revealTopMostCursor(t.source):e.revealBottomMostCursor(t.source))}}e.ColumnSelect=(0,a.E_)(new class extends i{constructor(){super({id:"columnSelect",precondition:void 0})}_getColumnSelectResult(e,t,i,s){if("undefined"===typeof s.position||"undefined"===typeof s.viewPosition||"undefined"===typeof s.mouseColumn)return null;const n=e.model.validatePosition(s.position),r=e.coordinatesConverter.validateViewPosition(new h.y(s.viewPosition.lineNumber,s.viewPosition.column),n),o=s.doColumnSelect?i.fromViewLineNumber:r.lineNumber,a=s.doColumnSelect?i.fromViewVisualColumn:s.mouseColumn-1;return u.columnSelect(e.cursorConfig,e,o,a,r.lineNumber,s.mouseColumn-1)}}),e.CursorColumnSelectLeft=(0,a.E_)(new class extends i{constructor(){super({id:"cursorColumnSelectLeft",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:3599,linux:{primary:0}}})}_getColumnSelectResult(e,t,i,s){return u.columnSelectLeft(e.cursorConfig,e,i)}}),e.CursorColumnSelectRight=(0,a.E_)(new class extends i{constructor(){super({id:"cursorColumnSelectRight",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:3601,linux:{primary:0}}})}_getColumnSelectResult(e,t,i,s){return u.columnSelectRight(e.cursorConfig,e,i)}});class r extends i{constructor(e){super(e),this._isPaged=e.isPaged}_getColumnSelectResult(e,t,i,s){return u.columnSelectUp(e.cursorConfig,e,i,this._isPaged)}}e.CursorColumnSelectUp=(0,a.E_)(new r({isPaged:!1,id:"cursorColumnSelectUp",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:3600,linux:{primary:0}}})),e.CursorColumnSelectPageUp=(0,a.E_)(new r({isPaged:!0,id:"cursorColumnSelectPageUp",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:3595,linux:{primary:0}}}));class l extends i{constructor(e){super(e),this._isPaged=e.isPaged}_getColumnSelectResult(e,t,i,s){return u.columnSelectDown(e.cursorConfig,e,i,this._isPaged)}}e.CursorColumnSelectDown=(0,a.E_)(new l({isPaged:!1,id:"cursorColumnSelectDown",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:3602,linux:{primary:0}}})),e.CursorColumnSelectPageDown=(0,a.E_)(new l({isPaged:!0,id:"cursorColumnSelectPageDown",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:3596,linux:{primary:0}}}));class g extends E{constructor(){super({id:"cursorMove",precondition:void 0,metadata:p.S.metadata})}runCoreEditorCommand(e,t){const i=p.S.parse(t);i&&this._runCursorMove(e,t.source,i)}_runCursorMove(e,t,i){e.model.pushStackElement(),e.setCursorStates(t,3,g._move(e,e.getCursorStates(),i)),e.revealAllCursors(t,!0)}static _move(e,t,i){const s=i.select,n=i.value;switch(i.direction){case 0:case 1:case 2:case 3:case 4:case 5:case 6:case 7:case 8:case 9:case 10:return p.c.simpleMove(e,t,i.direction,s,n,i.unit);case 11:case 13:case 12:case 14:return p.c.viewportMove(e,t,i.direction,s,n);default:return null}}}e.CursorMoveImpl=g,e.CursorMove=(0,a.E_)(new g);class m extends E{constructor(e){super(e),this._staticArgs=e.args}runCoreEditorCommand(e,t){let i=this._staticArgs;-1===this._staticArgs.value&&(i={direction:this._staticArgs.direction,unit:this._staticArgs.unit,select:this._staticArgs.select,value:t.pageSize||e.cursorConfig.pageSize}),e.model.pushStackElement(),e.setCursorStates(t.source,3,p.c.simpleMove(e,e.getCursorStates(),i.direction,i.select,i.value,i.unit)),e.revealAllCursors(t.source,!0)}}e.CursorLeft=(0,a.E_)(new m({args:{direction:0,unit:0,select:!1,value:1},id:"cursorLeft",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:15,mac:{primary:15,secondary:[288]}}})),e.CursorLeftSelect=(0,a.E_)(new m({args:{direction:0,unit:0,select:!0,value:1},id:"cursorLeftSelect",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1039}})),e.CursorRight=(0,a.E_)(new m({args:{direction:1,unit:0,select:!1,value:1},id:"cursorRight",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:17,mac:{primary:17,secondary:[292]}}})),e.CursorRightSelect=(0,a.E_)(new m({args:{direction:1,unit:0,select:!0,value:1},id:"cursorRightSelect",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1041}})),e.CursorUp=(0,a.E_)(new m({args:{direction:2,unit:2,select:!1,value:1},id:"cursorUp",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:16,mac:{primary:16,secondary:[302]}}})),e.CursorUpSelect=(0,a.E_)(new m({args:{direction:2,unit:2,select:!0,value:1},id:"cursorUpSelect",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1040,secondary:[3088],mac:{primary:1040},linux:{primary:1040}}})),e.CursorPageUp=(0,a.E_)(new m({args:{direction:2,unit:2,select:!1,value:-1},id:"cursorPageUp",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:11}})),e.CursorPageUpSelect=(0,a.E_)(new m({args:{direction:2,unit:2,select:!0,value:-1},id:"cursorPageUpSelect",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1035}})),e.CursorDown=(0,a.E_)(new m({args:{direction:3,unit:2,select:!1,value:1},id:"cursorDown",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:18,mac:{primary:18,secondary:[300]}}})),e.CursorDownSelect=(0,a.E_)(new m({args:{direction:3,unit:2,select:!0,value:1},id:"cursorDownSelect",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1042,secondary:[3090],mac:{primary:1042},linux:{primary:1042}}})),e.CursorPageDown=(0,a.E_)(new m({args:{direction:3,unit:2,select:!1,value:-1},id:"cursorPageDown",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:12}})),e.CursorPageDownSelect=(0,a.E_)(new m({args:{direction:3,unit:2,select:!0,value:-1},id:"cursorPageDownSelect",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1036}})),e.CreateCursor=(0,a.E_)(new class extends E{constructor(){super({id:"createCursor",precondition:void 0})}runCoreEditorCommand(e,t){if(!t.position)return;let i;i=t.wholeLine?p.c.line(e,e.getPrimaryCursorState(),!1,t.position,t.viewPosition):p.c.moveTo(e,e.getPrimaryCursorState(),!1,t.position,t.viewPosition);const s=e.getCursorStates();if(s.length>1){const n=i.modelState?i.modelState.position:null,r=i.viewState?i.viewState.position:null;for(let i=0,o=s.length;ir&&(n=r);const o=new d.Q(n,1,n,e.model.getLineMaxColumn(n));let a=0;if(i.at)switch(i.at){case y.RawAtArgument.Top:a=3;break;case y.RawAtArgument.Center:a=1;break;case y.RawAtArgument.Bottom:a=4}const l=e.coordinatesConverter.convertModelRangeToViewRange(o);e.revealRange(t.source,!1,l,a,0)}}),e.SelectAll=new class extends L{constructor(){super(a.tc)}runDOMCommand(e){n.gm&&(e.focus(),e.select()),e.ownerDocument.execCommand("selectAll")}runEditorCommand(e,t,i){const s=t._getViewModel();s&&this.runCoreEditorCommand(s,i)}runCoreEditorCommand(e,t){e.model.pushStackElement(),e.setCursorStates("keyboard",3,[p.c.selectAll(e,e.getPrimaryCursorState())])}},e.SetSelection=(0,a.E_)(new class extends E{constructor(){super({id:"setSelection",precondition:void 0})}runCoreEditorCommand(e,t){t.selection&&(e.model.pushStackElement(),e.setCursorStates(t.source,3,[c.MF.fromModelSelection(t.selection)]))}})}(w||(w={}));const R=_.M$.and(f.R.textInputFocus,f.R.columnSelection);function T(e,t){v.f.registerKeybindingRule({id:e,primary:t,when:R,weight:1})}function x(e){return e.register(),e}var k;T(w.CursorColumnSelectLeft.id,1039),T(w.CursorColumnSelectRight.id,1041),T(w.CursorColumnSelectUp.id,1040),T(w.CursorColumnSelectPageUp.id,1035),T(w.CursorColumnSelectDown.id,1042),T(w.CursorColumnSelectPageDown.id,1036),function(e){class t extends a.DX{runEditorCommand(e,t,i){const s=t._getViewModel();s&&this.runCoreEditingCommand(t,s,i||{})}}e.CoreEditingCommand=t,e.LineBreakInsert=(0,a.E_)(new class extends t{constructor(){super({id:"lineBreakInsert",precondition:f.R.writable,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:0,mac:{primary:301}}})}runCoreEditingCommand(e,t,i){e.pushUndoStop(),e.executeCommands(this.id,b.AO.lineBreakInsert(t.cursorConfig,t.model,t.getCursorStates().map((e=>e.modelState.selection))))}}),e.Outdent=(0,a.E_)(new class extends t{constructor(){super({id:"outdent",precondition:f.R.writable,kbOpts:{weight:0,kbExpr:_.M$.and(f.R.editorTextFocus,f.R.tabDoesNotMoveFocus),primary:1026}})}runCoreEditingCommand(e,t,i){e.pushUndoStop(),e.executeCommands(this.id,m.T.outdent(t.cursorConfig,t.model,t.getCursorStates().map((e=>e.modelState.selection)))),e.pushUndoStop()}}),e.Tab=(0,a.E_)(new class extends t{constructor(){super({id:"tab",precondition:f.R.writable,kbOpts:{weight:0,kbExpr:_.M$.and(f.R.editorTextFocus,f.R.tabDoesNotMoveFocus),primary:2}})}runCoreEditingCommand(e,t,i){e.pushUndoStop(),e.executeCommands(this.id,m.T.tab(t.cursorConfig,t.model,t.getCursorStates().map((e=>e.modelState.selection)))),e.pushUndoStop()}}),e.DeleteLeft=(0,a.E_)(new class extends t{constructor(){super({id:"deleteLeft",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:1,secondary:[1025],mac:{primary:1,secondary:[1025,294,257]}}})}runCoreEditingCommand(e,t,i){const[s,n]=g.g.deleteLeft(t.getPrevEditOperationType(),t.cursorConfig,t.model,t.getCursorStates().map((e=>e.modelState.selection)),t.getCursorAutoClosedCharacters());s&&e.pushUndoStop(),e.executeCommands(this.id,n),t.setPrevEditOperationType(2)}}),e.DeleteRight=(0,a.E_)(new class extends t{constructor(){super({id:"deleteRight",precondition:void 0,kbOpts:{weight:0,kbExpr:f.R.textInputFocus,primary:20,mac:{primary:20,secondary:[290,276]}}})}runCoreEditingCommand(e,t,i){const[s,n]=g.g.deleteRight(t.getPrevEditOperationType(),t.cursorConfig,t.model,t.getCursorStates().map((e=>e.modelState.selection)));s&&e.pushUndoStop(),e.executeCommands(this.id,n),t.setPrevEditOperationType(3)}}),e.Undo=new class extends L{constructor(){super(a.aU)}runDOMCommand(e){e.ownerDocument.execCommand("undo")}runEditorCommand(e,t,i){if(t.hasModel()&&!0!==t.getOption(92))return t.getModel().undo()}},e.Redo=new class extends L{constructor(){super(a.ih)}runDOMCommand(e){e.ownerDocument.execCommand("redo")}runEditorCommand(e,t,i){if(t.hasModel()&&!0!==t.getOption(92))return t.getModel().redo()}}}(k||(k={}));class A extends a.uB{constructor(e,t,i){super({id:e,precondition:void 0,metadata:i}),this._handlerId=t}runCommand(e,t){const i=e.get(l.T).getFocusedCodeEditor();i&&i.trigger("keyboard",this._handlerId,t)}}function N(e,t){x(new A("default:"+e,e)),x(new A(e,e,t))}N("type",{description:"Type",args:[{name:"args",schema:{type:"object",required:["text"],properties:{text:{type:"string"}}}}]}),N("replacePreviousChar"),N("compositionType"),N("compositionStart"),N("compositionEnd"),N("paste"),N("cut")},85411:(e,t,i)=>{"use strict";i.d(t,{l:()=>d,q:()=>l});var s=i(42731),n=i(17799),r=i(44320),o=i(79400),a=i(61292);function l(e){const t=new n.Vq;for(const i of e.items){const e=i.type;if("string"===i.kind){const s=new Promise((e=>i.getAsString(e)));t.append(e,(0,n.gf)(s))}else if("file"===i.kind){const s=i.getAsFile();s&&t.append(e,c(s))}}return t}function c(e){const t=e.path?o.r.parse(e.path):void 0;return(0,n.VX)(e.name,t,(async()=>new Uint8Array(await e.arrayBuffer())))}const h=Object.freeze([a.sV.EDITORS,a.sV.FILES,s.t.RESOURCES,s.t.INTERNAL_URI_LIST]);function d(e,t=!1){const i=l(e),a=i.get(s.t.INTERNAL_URI_LIST);if(a)i.replace(r.K.uriList,a);else if(t||!i.has(r.K.uriList)){const t=[];for(const i of e.items){const e=i.getAsFile();if(e){const i=e.path;try{i?t.push(o.r.file(i).toString()):t.push(o.r.parse(e.name,!0).toString())}catch{}}}t.length&&i.replace(r.K.uriList,(0,n.gf)(n.jt.create(t)))}for(const s of h)i.delete(s);return i}},34326:(e,t,i)=>{"use strict";i.d(t,{Np:()=>r,jA:()=>o,z9:()=>n});var s=i(23452);function n(e){return!(!e||"function"!==typeof e.getEditorType)&&e.getEditorType()===s._.ICodeEditor}function r(e){return!(!e||"function"!==typeof e.getEditorType)&&e.getEditorType()===s._.IDiffEditor}function o(e){return n(e)?e:r(e)?e.getModifiedEditor():function(e){return!!e&&"object"===typeof e&&"function"===typeof e.onDidChangeActiveEditor}(e)&&n(e.activeCodeEditor)?e.activeCodeEditor:null}},37734:(e,t,i)=>{"use strict";i.d(t,{$z:()=>f,BA:()=>v,DW:()=>_,Hh:()=>h,Qn:()=>C,dO:()=>m,i_:()=>p,nz:()=>c,wt:()=>g});var s=i(8597),n=i(34072),r=i(47358),o=i(90766),a=i(5662),l=i(66261);class c{constructor(e,t){this.x=e,this.y=t,this._pageCoordinatesBrand=void 0}toClientCoordinates(e){return new h(this.x-e.scrollX,this.y-e.scrollY)}}class h{constructor(e,t){this.clientX=e,this.clientY=t,this._clientCoordinatesBrand=void 0}toPageCoordinates(e){return new c(this.clientX+e.scrollX,this.clientY+e.scrollY)}}class d{constructor(e,t,i,s){this.x=e,this.y=t,this.width=i,this.height=s,this._editorPagePositionBrand=void 0}}class u{constructor(e,t){this.x=e,this.y=t,this._positionRelativeToEditorBrand=void 0}}function g(e){const t=s.BK(e);return new d(t.left,t.top,t.width,t.height)}function p(e,t,i){const s=t.width/e.offsetWidth,n=t.height/e.offsetHeight,r=(i.x-t.x)/s,o=(i.y-t.y)/n;return new u(r,o)}class m extends r.P{constructor(e,t,i){super(s.zk(i),e),this._editorMouseEventBrand=void 0,this.isFromPointerCapture=t,this.pos=new c(this.posx,this.posy),this.editorPos=g(i),this.relativePos=p(i,this.editorPos,this.pos)}}class f{constructor(e){this._editorViewDomNode=e}_create(e){return new m(e,!1,this._editorViewDomNode)}onContextMenu(e,t){return s.ko(e,"contextmenu",(e=>{t(this._create(e))}))}onMouseUp(e,t){return s.ko(e,"mouseup",(e=>{t(this._create(e))}))}onMouseDown(e,t){return s.ko(e,s.Bx.MOUSE_DOWN,(e=>{t(this._create(e))}))}onPointerDown(e,t){return s.ko(e,s.Bx.POINTER_DOWN,(e=>{t(this._create(e),e.pointerId)}))}onMouseLeave(e,t){return s.ko(e,s.Bx.MOUSE_LEAVE,(e=>{t(this._create(e))}))}onMouseMove(e,t){return s.ko(e,"mousemove",(e=>t(this._create(e))))}}class _{constructor(e){this._editorViewDomNode=e}_create(e){return new m(e,!1,this._editorViewDomNode)}onPointerUp(e,t){return s.ko(e,"pointerup",(e=>{t(this._create(e))}))}onPointerDown(e,t){return s.ko(e,s.Bx.POINTER_DOWN,(e=>{t(this._create(e),e.pointerId)}))}onPointerLeave(e,t){return s.ko(e,s.Bx.POINTER_LEAVE,(e=>{t(this._create(e))}))}onPointerMove(e,t){return s.ko(e,"pointermove",(e=>t(this._create(e))))}}class v extends a.jG{constructor(e){super(),this._editorViewDomNode=e,this._globalPointerMoveMonitor=this._register(new n._),this._keydownListener=null}startMonitoring(e,t,i,n,r){this._keydownListener=s.b2(e.ownerDocument,"keydown",(e=>{e.toKeyCodeChord().isModifierKey()||this._globalPointerMoveMonitor.stopMonitoring(!0,e.browserEvent)}),!0),this._globalPointerMoveMonitor.startMonitoring(e,t,i,(e=>{n(new m(e,!0,this._editorViewDomNode))}),(e=>{this._keydownListener.dispose(),r(e)}))}stopMonitoring(){this._globalPointerMoveMonitor.stopMonitoring(!0)}}class C{static{this._idPool=0}constructor(e){this._editor=e,this._instanceId=++C._idPool,this._counter=0,this._rules=new Map,this._garbageCollectionScheduler=new o.uC((()=>this.garbageCollect()),1e3)}createClassNameRef(e){const t=this.getOrCreateRule(e);return t.increaseRefCount(),{className:t.className,dispose:()=>{t.decreaseRefCount(),this._garbageCollectionScheduler.schedule()}}}getOrCreateRule(e){const t=this.computeUniqueKey(e);let i=this._rules.get(t);if(!i){const n=this._counter++;i=new b(t,`dyn-rule-${this._instanceId}-${n}`,s.Cl(this._editor.getContainerDomNode())?this._editor.getContainerDomNode():void 0,e),this._rules.set(t,i)}return i}computeUniqueKey(e){return JSON.stringify(e)}garbageCollect(){for(const e of this._rules.values())e.hasReferences()||(this._rules.delete(e.key),e.dispose())}}class b{constructor(e,t,i,n){this.key=e,this.className=t,this.properties=n,this._referenceCount=0,this._styleElementDisposables=new a.Cm,this._styleElement=s.li(i,void 0,this._styleElementDisposables),this._styleElement.textContent=this.getCssText(this.className,this.properties)}getCssText(e,t){let i=`.${e} {`;for(const s in t){const e=t[s];let n;n="object"===typeof e?(0,l.GuP)(e.id):e;i+=`\n\t${E(s)}: ${n};`}return i+="\n}",i}dispose(){this._styleElementDisposables.dispose(),this._styleElement=void 0}increaseRefCount(){this._referenceCount++}decreaseRefCount(){this._referenceCount--}hasReferences(){return this._referenceCount>0}}function E(e){return e.replace(/(^[A-Z])/,(([e])=>e.toLowerCase())).replace(/([A-Z])/g,(([e])=>`-${e.toLowerCase()}`))}},31450:(e,t,i)=>{"use strict";i.d(t,{DX:()=>y,E_:()=>x,Fl:()=>k,HW:()=>I,PF:()=>L,aU:()=>M,dS:()=>s,fE:()=>E,gW:()=>A,ih:()=>P,ke:()=>T,ks:()=>w,qO:()=>R,tc:()=>F,uB:()=>b,xX:()=>N});var s,n=i(78209),r=i(79400),o=i(80301),a=i(83069),l=i(23750),c=i(18938),h=i(27195),d=i(50091),u=i(32848),g=i(63591),p=i(59261),m=i(46359),f=i(90651),_=i(631),v=i(18801),C=i(8597);class b{constructor(e){this.id=e.id,this.precondition=e.precondition,this._kbOpts=e.kbOpts,this._menuOpts=e.menuOpts,this.metadata=e.metadata}register(){if(Array.isArray(this._menuOpts)?this._menuOpts.forEach(this._registerMenuItem,this):this._menuOpts&&this._registerMenuItem(this._menuOpts),this._kbOpts){const e=Array.isArray(this._kbOpts)?this._kbOpts:[this._kbOpts];for(const t of e){let e=t.kbExpr;this.precondition&&(e=e?u.M$.and(e,this.precondition):this.precondition);const i={id:this.id,weight:t.weight,args:t.args,when:e,primary:t.primary,secondary:t.secondary,win:t.win,linux:t.linux,mac:t.mac};p.f.registerKeybindingRule(i)}}d.w.registerCommand({id:this.id,handler:(e,t)=>this.runCommand(e,t),metadata:this.metadata})}_registerMenuItem(e){h.ZG.appendMenuItem(e.menuId,{group:e.group,command:{id:this.id,title:e.title,icon:e.icon,precondition:this.precondition},when:e.when,order:e.order})}}class E extends b{constructor(){super(...arguments),this._implementations=[]}addImplementation(e,t,i,s){return this._implementations.push({priority:e,name:t,implementation:i,when:s}),this._implementations.sort(((e,t)=>t.priority-e.priority)),{dispose:()=>{for(let e=0;e{if(e.get(u.fN).contextMatchesRules(i??void 0))return s(e,r,t)}))}runCommand(e,t){return y.runEditorCommand(e,t,this.precondition,((e,t,i)=>this.runEditorCommand(e,t,i)))}}class w extends y{static convertOptions(e){let t;function i(t){return t.menuId||(t.menuId=h.D8.EditorContext),t.title||(t.title=e.label),t.when=u.M$.and(e.precondition,t.when),t}return t=Array.isArray(e.menuOpts)?e.menuOpts:e.menuOpts?[e.menuOpts]:[],Array.isArray(e.contextMenuOpts)?t.push(...e.contextMenuOpts.map(i)):e.contextMenuOpts&&t.push(i(e.contextMenuOpts)),e.menuOpts=t,e}constructor(e){super(w.convertOptions(e)),this.label=e.label,this.alias=e.alias}runEditorCommand(e,t,i){return this.reportTelemetry(e,t),this.run(e,t,i||{})}reportTelemetry(e,t){e.get(f.k).publicLog2("editorActionInvoked",{name:this.label,id:this.id})}}class L extends w{constructor(){super(...arguments),this._implementations=[]}addImplementation(e,t){return this._implementations.push([e,t]),this._implementations.sort(((e,t)=>t[0]-e[0])),{dispose:()=>{for(let e=0;e{const i=e.get(u.fN),n=e.get(v.rr);if(i.contextMatchesRules(this.desc.precondition??void 0))return this.runEditorCommand(e,s,...t);n.debug("[EditorAction2] NOT running command because its precondition is FALSE",this.desc.id,this.desc.precondition?.serialize())}))}}function T(e,t){d.w.registerCommand(e,(function(e,...i){const s=e.get(g._Y),[n,o]=i;(0,_.j)(r.r.isUri(n)),(0,_.j)(a.y.isIPosition(o));const h=e.get(l.IModelService).getModel(n);if(h){const e=a.y.lift(o);return s.invokeFunction(t,h,e,...i.slice(2))}return e.get(c.ITextModelService).createModelReference(n).then((e=>new Promise(((n,r)=>{try{n(s.invokeFunction(t,e.object.textEditorModel,a.y.lift(o),i.slice(2)))}catch(l){r(l)}})).finally((()=>{e.dispose()}))))}))}function x(e){return O.INSTANCE.registerEditorCommand(e),e}function k(e){const t=new e;return O.INSTANCE.registerEditorAction(t),t}function A(e){return O.INSTANCE.registerEditorAction(e),e}function N(e){O.INSTANCE.registerEditorAction(e)}function I(e,t,i){O.INSTANCE.registerEditorContribution(e,t,i)}!function(e){e.getEditorCommand=function(e){return O.INSTANCE.getEditorCommand(e)},e.getEditorActions=function(){return O.INSTANCE.getEditorActions()},e.getEditorContributions=function(){return O.INSTANCE.getEditorContributions()},e.getSomeEditorContributions=function(e){return O.INSTANCE.getEditorContributions().filter((t=>e.indexOf(t.id)>=0))},e.getDiffEditorContributions=function(){return O.INSTANCE.getDiffEditorContributions()}}(s||(s={}));class O{static{this.INSTANCE=new O}constructor(){this.editorContributions=[],this.diffEditorContributions=[],this.editorActions=[],this.editorCommands=Object.create(null)}registerEditorContribution(e,t,i){this.editorContributions.push({id:e,ctor:t,instantiation:i})}getEditorContributions(){return this.editorContributions.slice(0)}getDiffEditorContributions(){return this.diffEditorContributions.slice(0)}registerEditorAction(e){e.register(),this.editorActions.push(e)}getEditorActions(){return this.editorActions}registerEditorCommand(e){e.register(),this.editorCommands[e.id]=e}getEditorCommand(e){return this.editorCommands[e]||null}}function D(e){return e.register(),e}m.O.add("editor.contributions",O.INSTANCE);const M=D(new E({id:"undo",precondition:void 0,kbOpts:{weight:0,primary:2104},menuOpts:[{menuId:h.D8.MenubarEditMenu,group:"1_do",title:n.kg({key:"miUndo",comment:["&& denotes a mnemonic"]},"&&Undo"),order:1},{menuId:h.D8.CommandPalette,group:"",title:n.kg("undo","Undo"),order:1}]}));D(new S(M,{id:"default:undo",precondition:void 0}));const P=D(new E({id:"redo",precondition:void 0,kbOpts:{weight:0,primary:2103,secondary:[3128],mac:{primary:3128}},menuOpts:[{menuId:h.D8.MenubarEditMenu,group:"1_do",title:n.kg({key:"miRedo",comment:["&& denotes a mnemonic"]},"&&Redo"),order:2},{menuId:h.D8.CommandPalette,group:"",title:n.kg("redo","Redo"),order:1}]}));D(new S(P,{id:"default:redo",precondition:void 0}));const F=D(new E({id:"editor.action.selectAll",precondition:void 0,kbOpts:{weight:0,kbExpr:null,primary:2079},menuOpts:[{menuId:h.D8.MenubarSelectionMenu,group:"1_basic",title:n.kg({key:"miSelectAll",comment:["&& denotes a mnemonic"]},"&&Select All"),order:1},{menuId:h.D8.CommandPalette,group:"",title:n.kg("selectAll","Select All"),order:1}]}))},38844:(e,t,i)=>{"use strict";i.d(t,{Qg:()=>u,Ud:()=>c,jD:()=>d});var s=i(51241),n=i(5662),r=i(31308),o=i(49154),a=i(87958),l=i(75326);function c(e){return h.get(e)}class h extends n.jG{static{this._map=new Map}static get(e){let t=h._map.get(e);if(!t){t=new h(e),h._map.set(e,t);const i=e.onDidDispose((()=>{const t=h._map.get(e);t&&(h._map.delete(e),t.dispose(),i.dispose())}))}return t}_beginUpdate(){this._updateCounter++,1===this._updateCounter&&(this._currentTransaction=new o.XL((()=>{})))}_endUpdate(){if(this._updateCounter--,0===this._updateCounter){const e=this._currentTransaction;this._currentTransaction=void 0,e.finish()}}constructor(e){super(),this.editor=e,this._updateCounter=0,this._currentTransaction=void 0,this._model=(0,r.FY)(this,this.editor.getModel()),this.model=this._model,this.isReadonly=(0,r.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(92))),this._versionId=(0,r.Zh)({owner:this,lazy:!0},this.editor.getModel()?.getVersionId()??null),this.versionId=this._versionId,this._selections=(0,r.Zh)({owner:this,equalsFn:(0,s.KC)((0,s.S3)(l.L.selectionsEqual)),lazy:!0},this.editor.getSelections()??null),this.selections=this._selections,this.isFocused=(0,r.y0)(this,(e=>{const t=this.editor.onDidFocusEditorWidget(e),i=this.editor.onDidBlurEditorWidget(e);return{dispose(){t.dispose(),i.dispose()}}}),(()=>this.editor.hasWidgetFocus())),this.value=(0,a.dQ)(this,(e=>(this.versionId.read(e),this.model.read(e)?.getValue()??"")),((e,t)=>{const i=this.model.get();null!==i&&e!==i.getValue()&&i.setValue(e)})),this.valueIsEmpty=(0,r.un)(this,(e=>(this.versionId.read(e),0===this.editor.getModel()?.getValueLength()))),this.cursorSelection=(0,r.C)({owner:this,equalsFn:(0,s.KC)(l.L.selectionsEqual)},(e=>this.selections.read(e)?.[0]??null)),this.onDidType=(0,r.Yd)(this),this.scrollTop=(0,r.y0)(this.editor.onDidScrollChange,(()=>this.editor.getScrollTop())),this.scrollLeft=(0,r.y0)(this.editor.onDidScrollChange,(()=>this.editor.getScrollLeft())),this.layoutInfo=(0,r.y0)(this.editor.onDidLayoutChange,(()=>this.editor.getLayoutInfo())),this.layoutInfoContentLeft=this.layoutInfo.map((e=>e.contentLeft)),this.layoutInfoDecorationsLeft=this.layoutInfo.map((e=>e.decorationsLeft)),this.contentWidth=(0,r.y0)(this.editor.onDidContentSizeChange,(()=>this.editor.getContentWidth())),this._overlayWidgetCounter=0,this._register(this.editor.onBeginUpdate((()=>this._beginUpdate()))),this._register(this.editor.onEndUpdate((()=>this._endUpdate()))),this._register(this.editor.onDidChangeModel((()=>{this._beginUpdate();try{this._model.set(this.editor.getModel(),this._currentTransaction),this._forceUpdate()}finally{this._endUpdate()}}))),this._register(this.editor.onDidType((e=>{this._beginUpdate();try{this._forceUpdate(),this.onDidType.trigger(this._currentTransaction,e)}finally{this._endUpdate()}}))),this._register(this.editor.onDidChangeModelContent((e=>{this._beginUpdate();try{this._versionId.set(this.editor.getModel()?.getVersionId()??null,this._currentTransaction,e),this._forceUpdate()}finally{this._endUpdate()}}))),this._register(this.editor.onDidChangeCursorSelection((e=>{this._beginUpdate();try{this._selections.set(this.editor.getSelections(),this._currentTransaction,e),this._forceUpdate()}finally{this._endUpdate()}})))}forceUpdate(e){this._beginUpdate();try{if(this._forceUpdate(),!e)return;return e(this._currentTransaction)}finally{this._endUpdate()}}_forceUpdate(){this._beginUpdate();try{this._model.set(this.editor.getModel(),this._currentTransaction),this._versionId.set(this.editor.getModel()?.getVersionId()??null,this._currentTransaction,void 0),this._selections.set(this.editor.getSelections(),this._currentTransaction,void 0)}finally{this._endUpdate()}}getOption(e){return(0,r.y0)(this,(t=>this.editor.onDidChangeConfiguration((i=>{i.hasChanged(e)&&t(void 0)}))),(()=>this.editor.getOption(e)))}setDecorations(e){const t=new n.Cm,i=this.editor.createDecorationsCollection();return t.add((0,r.zL)({owner:this,debugName:()=>`Apply decorations from ${e.debugName}`},(t=>{const s=e.read(t);i.set(s)}))),t.add({dispose:()=>{i.clear()}}),t}createOverlayWidget(e){const t="observableOverlayWidget"+this._overlayWidgetCounter++,i={getDomNode:()=>e.domNode,getPosition:()=>e.position.get(),getId:()=>t,allowEditorOverflow:e.allowEditorOverflow,getMinContentWidthInPx:()=>e.minContentWidthInPx.get()};this.editor.addOverlayWidget(i);const s=(0,r.fm)((t=>{e.position.read(t),e.minContentWidthInPx.read(t),this.editor.layoutOverlayWidget(i)}));return(0,n.s)((()=>{s.dispose(),this.editor.removeOverlayWidget(i)}))}}function d(e,t){return(0,r.ht)({createEmptyChangeSummary:()=>({deltas:[],didChange:!1}),handleChange:(t,i)=>{if(t.didChange(e)){const e=t.change;void 0!==e&&i.deltas.push(e),i.didChange=!0}return!0}},((i,s)=>{const n=e.read(i);s.didChange&&t(n,s.deltas)}))}function u(e,t){const i=new n.Cm,s=d(e,((e,s)=>{i.clear(),t(e,s,i)}));return{dispose(){s.dispose(),i.dispose()}}}},80537:(e,t,i)=>{"use strict";i.d(t,{cw:()=>l,jN:()=>a,nu:()=>o});var s=i(63591),n=i(79400),r=i(631);const o=(0,s.u1)("IWorkspaceEditService");class a{constructor(e){this.metadata=e}static convert(e){return e.edits.map((e=>{if(l.is(e))return l.lift(e);if(c.is(e))return c.lift(e);throw new Error("Unsupported edit")}))}}class l extends a{static is(e){return e instanceof l||(0,r.Gv)(e)&&n.r.isUri(e.resource)&&(0,r.Gv)(e.textEdit)}static lift(e){return e instanceof l?e:new l(e.resource,e.textEdit,e.versionId,e.metadata)}constructor(e,t,i=void 0,s){super(s),this.resource=e,this.textEdit=t,this.versionId=i}}class c extends a{static is(e){return e instanceof c||(0,r.Gv)(e)&&(Boolean(e.newResource)||Boolean(e.oldResource))}static lift(e){return e instanceof c?e:new c(e.oldResource,e.newResource,e.options,e.metadata)}constructor(e,t,i={},s){super(s),this.oldResource=e,this.newResource=t,this.options=i}}},80301:(e,t,i)=>{"use strict";i.d(t,{T:()=>s});const s=(0,i(63591).u1)("codeEditorService")},55190:(e,t,i)=>{"use strict";i.d(t,{D:()=>s});class s{static capture(e){if(0===e.getScrollTop()||e.hasPendingScrollAnimation())return new s(e.getScrollTop(),e.getContentHeight(),null,0,null);let t=null,i=0;const n=e.getVisibleRanges();if(n.length>0){t=n[0].getStartPosition();const s=e.getTopForPosition(t.lineNumber,t.column);i=e.getScrollTop()-s}return new s(e.getScrollTop(),e.getContentHeight(),t,i,e.getPosition())}constructor(e,t,i,s,n){this._initialScrollTop=e,this._initialContentHeight=t,this._visiblePosition=i,this._visiblePositionScrollDelta=s,this._cursorPosition=n}restore(e){if((this._initialContentHeight!==e.getContentHeight()||this._initialScrollTop!==e.getScrollTop())&&this._visiblePosition){const t=e.getTopForPosition(this._visiblePosition.lineNumber,this._visiblePosition.column);e.setScrollTop(t+this._visiblePositionScrollDelta)}}restoreRelativeVerticalPositionOfCursor(e){if(this._initialContentHeight===e.getContentHeight()&&this._initialScrollTop===e.getScrollTop())return;const t=e.getPosition();if(!this._cursorPosition||!t)return;const i=e.getTopForLineNumber(t.lineNumber)-e.getTopForLineNumber(this._cursorPosition.lineNumber);e.setScrollTop(e.getScrollTop()+i,1)}}},80624:(e,t,i)=>{"use strict";i.d(t,{BG:()=>r,IO:()=>a,Y:()=>o,eh:()=>n,pj:()=>c,qN:()=>l});class s{constructor(e,t){this._restrictedRenderingContextBrand=void 0,this._viewLayout=e,this.viewportData=t,this.scrollWidth=this._viewLayout.getScrollWidth(),this.scrollHeight=this._viewLayout.getScrollHeight(),this.visibleRange=this.viewportData.visibleRange,this.bigNumbersDelta=this.viewportData.bigNumbersDelta;const i=this._viewLayout.getCurrentViewport();this.scrollTop=i.top,this.scrollLeft=i.left,this.viewportWidth=i.width,this.viewportHeight=i.height}getScrolledTopFromAbsoluteTop(e){return e-this.scrollTop}getVerticalOffsetForLineNumber(e,t){return this._viewLayout.getVerticalOffsetForLineNumber(e,t)}getVerticalOffsetAfterLineNumber(e,t){return this._viewLayout.getVerticalOffsetAfterLineNumber(e,t)}getDecorationsInViewport(){return this.viewportData.getDecorationsInViewport()}}class n extends s{constructor(e,t,i){super(e,t),this._renderingContextBrand=void 0,this._viewLines=i}linesVisibleRangesForRange(e,t){return this._viewLines.linesVisibleRangesForRange(e,t)}visibleRangeForPosition(e){return this._viewLines.visibleRangeForPosition(e)}}class r{constructor(e,t,i,s){this.outsideRenderedLine=e,this.lineNumber=t,this.ranges=i,this.continuesOnNextLine=s}}class o{static from(e){const t=new Array(e.length);for(let i=0,s=e.length;i{"use strict";i.d(t,{Gb:()=>m,Ax:()=>p,rk:()=>S});var s=i(60413),n=i(55275),r=i(98067),o=i(80624);class a{static _createRange(){return this._handyReadyRange||(this._handyReadyRange=document.createRange()),this._handyReadyRange}static _detachRange(e,t){e.selectNodeContents(t)}static _readClientRects(e,t,i,s,n){const r=this._createRange();try{return r.setStart(e,t),r.setEnd(i,s),r.getClientRects()}catch(o){return null}finally{this._detachRange(r,n)}}static _mergeAdjacentRanges(e){if(1===e.length)return e;e.sort(o.IO.compare);const t=[];let i=0,s=e[0];for(let n=1,r=e.length;n=r.left?s.width=Math.max(s.width,r.left+r.width-s.left):(t[i++]=s,s=r)}return t[i++]=s,t}static _createHorizontalRangesFromClientRects(e,t,i){if(!e||0===e.length)return null;const s=[];for(let n=0,r=e.length;no)return null;if((t=Math.min(o,Math.max(0,t)))===(s=Math.min(o,Math.max(0,s)))&&i===n&&0===i&&!e.children[t].firstChild){const i=e.children[t].getClientRects();return r.markDidDomLayout(),this._createHorizontalRangesFromClientRects(i,r.clientRectDeltaLeft,r.clientRectScale)}t!==s&&s>0&&0===n&&(s--,n=1073741824);let a=e.children[t].firstChild,l=e.children[s].firstChild;if(a&&l||(!a&&0===i&&t>0&&(a=e.children[t-1].firstChild,i=1073741824),!l&&0===n&&s>0&&(l=e.children[s-1].firstChild,n=1073741824)),!a||!l)return null;i=Math.min(a.textContent.length,Math.max(0,i)),n=Math.min(l.textContent.length,Math.max(0,n));const c=this._readClientRects(a,i,l,n,r.endNode);return r.markDidDomLayout(),this._createHorizontalRangesFromClientRects(c,r.clientRectDeltaLeft,r.clientRectScale)}}var l=i(25521),c=i(35600),h=i(86723),d=i(87908);const u=!!r.ib||!(r.j9||s.gm||s.nr);let g=!0;class p{constructor(e,t){this.themeType=t;const i=e.options,s=i.get(50),n=i.get(38);this.renderWhitespace="off"===n?i.get(100):"none",this.renderControlCharacters=i.get(95),this.spaceWidth=s.spaceWidth,this.middotWidth=s.middotWidth,this.wsmiddotWidth=s.wsmiddotWidth,this.useMonospaceOptimizations=s.isMonospace&&!i.get(33),this.canUseHalfwidthRightwardsArrow=s.canUseHalfwidthRightwardsArrow,this.lineHeight=i.get(67),this.stopRenderingLineAfter=i.get(118),this.fontLigatures=i.get(51)}equals(e){return this.themeType===e.themeType&&this.renderWhitespace===e.renderWhitespace&&this.renderControlCharacters===e.renderControlCharacters&&this.spaceWidth===e.spaceWidth&&this.middotWidth===e.middotWidth&&this.wsmiddotWidth===e.wsmiddotWidth&&this.useMonospaceOptimizations===e.useMonospaceOptimizations&&this.canUseHalfwidthRightwardsArrow===e.canUseHalfwidthRightwardsArrow&&this.lineHeight===e.lineHeight&&this.stopRenderingLineAfter===e.stopRenderingLineAfter&&this.fontLigatures===e.fontLigatures}}class m{static{this.CLASS_NAME="view-line"}constructor(e){this._options=e,this._isMaybeInvalid=!0,this._renderedViewLine=null}getDomNode(){return this._renderedViewLine&&this._renderedViewLine.domNode?this._renderedViewLine.domNode.domNode:null}setDomNode(e){if(!this._renderedViewLine)throw new Error("I have no rendered view line to set the dom node to...");this._renderedViewLine.domNode=(0,n.Z)(e)}onContentChanged(){this._isMaybeInvalid=!0}onTokensChanged(){this._isMaybeInvalid=!0}onDecorationsChanged(){this._isMaybeInvalid=!0}onOptionsChanged(e){this._isMaybeInvalid=!0,this._options=e}onSelectionChanged(){return!(!(0,h.Bb)(this._options.themeType)&&"selection"!==this._options.renderWhitespace)&&(this._isMaybeInvalid=!0,!0)}renderLine(e,t,i,s,n){if(!1===this._isMaybeInvalid)return!1;this._isMaybeInvalid=!1;const r=s.getViewLineRenderingData(e),o=this._options,a=l.d.filter(r.inlineDecorations,e,r.minColumn,r.maxColumn);let p=null;if((0,h.Bb)(o.themeType)||"selection"===this._options.renderWhitespace){const t=s.selections;for(const i of t){if(i.endLineNumbere)continue;const t=i.startLineNumber===e?i.startColumn:r.minColumn,s=i.endLineNumber===e?i.endColumn:r.maxColumn;t');const v=(0,c.UW)(_,n);n.appendString("");let b=null;return g&&u&&r.isBasicASCII&&o.useMonospaceOptimizations&&0===v.containsForeignElements&&(b=new f(this._renderedViewLine?this._renderedViewLine.domNode:null,_,v.characterMapping)),b||(b=C(this._renderedViewLine?this._renderedViewLine.domNode:null,_,v.characterMapping,v.containsRTL,v.containsForeignElements)),this._renderedViewLine=b,!0}layoutLine(e,t,i){this._renderedViewLine&&this._renderedViewLine.domNode&&(this._renderedViewLine.domNode.setTop(t),this._renderedViewLine.domNode.setHeight(i))}getWidth(e){return this._renderedViewLine?this._renderedViewLine.getWidth(e):0}getWidthIsFast(){return!this._renderedViewLine||this._renderedViewLine.getWidthIsFast()}needsMonospaceFontCheck(){return!!this._renderedViewLine&&this._renderedViewLine instanceof f}monospaceAssumptionsAreValid(){return this._renderedViewLine&&this._renderedViewLine instanceof f?this._renderedViewLine.monospaceAssumptionsAreValid():g}onMonospaceAssumptionsInvalidated(){this._renderedViewLine&&this._renderedViewLine instanceof f&&(this._renderedViewLine=this._renderedViewLine.toSlowRenderedLine())}getVisibleRangesForRange(e,t,i,s){if(!this._renderedViewLine)return null;t=Math.min(this._renderedViewLine.input.lineContent.length+1,Math.max(1,t)),i=Math.min(this._renderedViewLine.input.lineContent.length+1,Math.max(1,i));const n=this._renderedViewLine.input.stopRenderingLineAfter;if(-1!==n&&t>n+1&&i>n+1)return new o.pj(!0,[new o.IO(this.getWidth(s),0)]);-1!==n&&t>n+1&&(t=n+1),-1!==n&&i>n+1&&(i=n+1);const r=this._renderedViewLine.getVisibleRangesForRange(e,t,i,s);return r&&r.length>0?new o.pj(!1,r):null}getColumnOfNodeOffset(e,t){return this._renderedViewLine?this._renderedViewLine.getColumnOfNodeOffset(e,t):1}}class f{constructor(e,t,i){this._cachedWidth=-1,this.domNode=e,this.input=t;const s=Math.floor(t.lineContent.length/300);if(s>0){this._keyColumnPixelOffsetCache=new Float32Array(s);for(let e=0;e=2&&(console.warn("monospace assumptions have been violated, therefore disabling monospace optimizations!"),g=!1)}return g}toSlowRenderedLine(){return C(this.domNode,this.input,this._characterMapping,!1,0)}getVisibleRangesForRange(e,t,i,s){const n=this._getColumnPixelOffset(e,t,s),r=this._getColumnPixelOffset(e,i,s);return[new o.IO(n,r-n)]}_getColumnPixelOffset(e,t,i){if(t<=300){const e=this._characterMapping.getHorizontalOffset(t);return this._charWidth*e}const s=Math.floor((t-1)/300)-1,n=300*(s+1)+1;let r=-1;if(this._keyColumnPixelOffsetCache&&(r=this._keyColumnPixelOffsetCache[s],-1===r&&(r=this._actualReadPixelOffset(e,n,i),this._keyColumnPixelOffsetCache[s]=r)),-1===r){const e=this._characterMapping.getHorizontalOffset(t);return this._charWidth*e}const o=this._characterMapping.getHorizontalOffset(n),a=this._characterMapping.getHorizontalOffset(t);return r+this._charWidth*(a-o)}_getReadingTarget(e){return e.domNode.firstChild}_actualReadPixelOffset(e,t,i){if(!this.domNode)return-1;const s=this._characterMapping.getDomPosition(t),n=a.readHorizontalRanges(this._getReadingTarget(this.domNode),s.partIndex,s.charIndex,s.partIndex,s.charIndex,i);return n&&0!==n.length?n[0].left:-1}getColumnOfNodeOffset(e,t){return S(this._characterMapping,e,t)}}class _{constructor(e,t,i,s,n){if(this.domNode=e,this.input=t,this._characterMapping=i,this._isWhitespaceOnly=/^\s*$/.test(t.lineContent),this._containsForeignElements=n,this._cachedWidth=-1,this._pixelOffsetCache=null,!s||0===this._characterMapping.length){this._pixelOffsetCache=new Float32Array(Math.max(2,this._characterMapping.length+1));for(let e=0,t=this._characterMapping.length;e<=t;e++)this._pixelOffsetCache[e]=-1}}_getReadingTarget(e){return e.domNode.firstChild}getWidth(e){return this.domNode?(-1===this._cachedWidth&&(this._cachedWidth=this._getReadingTarget(this.domNode).offsetWidth,e?.markDidDomLayout()),this._cachedWidth):0}getWidthIsFast(){return-1!==this._cachedWidth}getVisibleRangesForRange(e,t,i,s){if(!this.domNode)return null;if(null!==this._pixelOffsetCache){const n=this._readPixelOffset(this.domNode,e,t,s);if(-1===n)return null;const r=this._readPixelOffset(this.domNode,e,i,s);return-1===r?null:[new o.IO(n,r-n)]}return this._readVisibleRangesForRange(this.domNode,e,t,i,s)}_readVisibleRangesForRange(e,t,i,s,n){if(i===s){const s=this._readPixelOffset(e,t,i,n);return-1===s?null:[new o.IO(s,0)]}return this._readRawVisibleRangesForRange(e,i,s,n)}_readPixelOffset(e,t,i,s){if(0===this._characterMapping.length){if(0===this._containsForeignElements)return 0;if(2===this._containsForeignElements)return 0;if(1===this._containsForeignElements)return this.getWidth(s);const t=this._getReadingTarget(e);return t.firstChild?(s.markDidDomLayout(),t.firstChild.offsetWidth):0}if(null!==this._pixelOffsetCache){const n=this._pixelOffsetCache[i];if(-1!==n)return n;const r=this._actualReadPixelOffset(e,t,i,s);return this._pixelOffsetCache[i]=r,r}return this._actualReadPixelOffset(e,t,i,s)}_actualReadPixelOffset(e,t,i,s){if(0===this._characterMapping.length){const t=a.readHorizontalRanges(this._getReadingTarget(e),0,0,0,0,s);return t&&0!==t.length?t[0].left:-1}if(i===this._characterMapping.length&&this._isWhitespaceOnly&&0===this._containsForeignElements)return this.getWidth(s);const n=this._characterMapping.getDomPosition(i),r=a.readHorizontalRanges(this._getReadingTarget(e),n.partIndex,n.charIndex,n.partIndex,n.charIndex,s);if(!r||0===r.length)return-1;const o=r[0].left;if(this.input.isBasicASCII){const e=this._characterMapping.getHorizontalOffset(i),t=Math.round(this.input.spaceWidth*e);if(Math.abs(t-o)<=1)return t}return o}_readRawVisibleRangesForRange(e,t,i,s){if(1===t&&i===this._characterMapping.length)return[new o.IO(0,this.getWidth(s))];const n=this._characterMapping.getDomPosition(t),r=this._characterMapping.getDomPosition(i);return a.readHorizontalRanges(this._getReadingTarget(e),n.partIndex,n.charIndex,r.partIndex,r.charIndex,s)}getColumnOfNodeOffset(e,t){return S(this._characterMapping,e,t)}}class v extends _{_readVisibleRangesForRange(e,t,i,s,n){const r=super._readVisibleRangesForRange(e,t,i,s,n);if(!r||0===r.length||i===s||1===i&&s===this._characterMapping.length)return r;if(!this.input.containsRTL){const i=this._readPixelOffset(e,t,s,n);if(-1!==i){const e=r[r.length-1];e.left{"use strict";i.d(t,{x:()=>Xn});var s=i(37550),n=i(31450),r=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},o=function(e,t){return function(i,s){t(i,s,e)}};let a=class{static{this.ID="editor.contrib.markerDecorations"}constructor(e,t){}dispose(){}};a=r([o(1,s.IMarkerDecorationsService)],a),(0,n.HW)(a.ID,a,0);var l=i(8597),c=i(64383),h=i(41234),d=i(5662),u=i(36456),g=i(73157),p=i(60413),m=i(25890),f=i(10146),_=i(98067),v=i(4983),C=i(28433);class b{static{this.items=[]}constructor(e,t){this.key=e,this.migrate=t}apply(e){const t=b._read(e,this.key);this.migrate(t,(t=>b._read(e,t)),((t,i)=>b._write(e,t,i)))}static _read(e,t){if("undefined"===typeof e)return;const i=t.indexOf(".");if(i>=0){const s=t.substring(0,i);return this._read(e[s],t.substring(i+1))}return e[t]}static _write(e,t,i){const s=t.indexOf(".");if(s>=0){const n=t.substring(0,s);return e[n]=e[n]||{},void this._write(e[n],t.substring(s+1),i)}e[t]=i}}function E(e,t){b.items.push(new b(e,t))}function S(e,t){E(e,((i,s,n)=>{if("undefined"!==typeof i)for(const[r,o]of t)if(i===r)return void n(e,o)}))}S("wordWrap",[[!0,"on"],[!1,"off"]]),S("lineNumbers",[[!0,"on"],[!1,"off"]]),S("cursorBlinking",[["visible","solid"]]),S("renderWhitespace",[[!0,"boundary"],[!1,"none"]]),S("renderLineHighlight",[[!0,"line"],[!1,"none"]]),S("acceptSuggestionOnEnter",[[!0,"on"],[!1,"off"]]),S("tabCompletion",[[!1,"off"],[!0,"onlySnippets"]]),S("hover",[[!0,{enabled:!0}],[!1,{enabled:!1}]]),S("parameterHints",[[!0,{enabled:!0}],[!1,{enabled:!1}]]),S("autoIndent",[[!1,"advanced"],[!0,"full"]]),S("matchBrackets",[[!0,"always"],[!1,"never"]]),S("renderFinalNewline",[[!0,"on"],[!1,"off"]]),S("cursorSmoothCaretAnimation",[[!0,"on"],[!1,"off"]]),S("occurrencesHighlight",[[!0,"singleFile"],[!1,"off"]]),S("wordBasedSuggestions",[[!0,"matchingDocuments"],[!1,"off"]]),E("autoClosingBrackets",((e,t,i)=>{!1===e&&(i("autoClosingBrackets","never"),"undefined"===typeof t("autoClosingQuotes")&&i("autoClosingQuotes","never"),"undefined"===typeof t("autoSurround")&&i("autoSurround","never"))})),E("renderIndentGuides",((e,t,i)=>{"undefined"!==typeof e&&(i("renderIndentGuides",void 0),"undefined"===typeof t("guides.indentation")&&i("guides.indentation",!!e))})),E("highlightActiveIndentGuide",((e,t,i)=>{"undefined"!==typeof e&&(i("highlightActiveIndentGuide",void 0),"undefined"===typeof t("guides.highlightActiveIndentation")&&i("guides.highlightActiveIndentation",!!e))}));const y={method:"showMethods",function:"showFunctions",constructor:"showConstructors",deprecated:"showDeprecated",field:"showFields",variable:"showVariables",class:"showClasses",struct:"showStructs",interface:"showInterfaces",module:"showModules",property:"showProperties",event:"showEvents",operator:"showOperators",unit:"showUnits",value:"showValues",constant:"showConstants",enum:"showEnums",enumMember:"showEnumMembers",keyword:"showKeywords",text:"showWords",color:"showColors",file:"showFiles",reference:"showReferences",folder:"showFolders",typeParameter:"showTypeParameters",snippet:"showSnippets"};E("suggest.filteredTypes",((e,t,i)=>{if(e&&"object"===typeof e){for(const s of Object.entries(y)){!1===e[s[0]]&&"undefined"===typeof t(`suggest.${s[1]}`)&&i(`suggest.${s[1]}`,!1)}i("suggest.filteredTypes",void 0)}})),E("quickSuggestions",((e,t,i)=>{if("boolean"===typeof e){const t=e?"on":"off";i("quickSuggestions",{comments:t,strings:t,other:t})}})),E("experimental.stickyScroll.enabled",((e,t,i)=>{"boolean"===typeof e&&(i("experimental.stickyScroll.enabled",void 0),"undefined"===typeof t("stickyScroll.enabled")&&i("stickyScroll.enabled",e))})),E("experimental.stickyScroll.maxLineCount",((e,t,i)=>{"number"===typeof e&&(i("experimental.stickyScroll.maxLineCount",void 0),"undefined"===typeof t("stickyScroll.maxLineCount")&&i("stickyScroll.maxLineCount",e))})),E("codeActionsOnSave",((e,t,i)=>{if(e&&"object"===typeof e){let t=!1;const s={};for(const i of Object.entries(e))"boolean"===typeof i[1]?(t=!0,s[i[0]]=i[1]?"explicit":"never"):s[i[0]]=i[1];t&&i("codeActionsOnSave",s)}})),E("codeActionWidget.includeNearbyQuickfixes",((e,t,i)=>{"boolean"===typeof e&&(i("codeActionWidget.includeNearbyQuickfixes",void 0),"undefined"===typeof t("codeActionWidget.includeNearbyQuickFixes")&&i("codeActionWidget.includeNearbyQuickFixes",e))})),E("lightbulb.enabled",((e,t,i)=>{"boolean"===typeof e&&i("lightbulb.enabled",e?void 0:"off")}));var w=i(77163),L=i(87908),R=i(79027),T=i(74196),x=i(253),k=i(94106),A=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},N=function(e,t){return function(i,s){t(i,s,e)}};let I=class extends d.jG{constructor(e,t,i,s,n){super(),this._accessibilityService=n,this._onDidChange=this._register(new h.vl),this.onDidChange=this._onDidChange.event,this._onDidChangeFast=this._register(new h.vl),this.onDidChangeFast=this._onDidChangeFast.event,this._isDominatedByLongLines=!1,this._viewLineCount=1,this._lineNumbersDigitCount=1,this._reservedHeight=0,this._glyphMarginDecorationLaneCount=1,this._computeOptionsMemory=new L.n0,this.isSimpleWidget=e,this.contextMenuId=t,this._containerObserver=this._register(new v.u(s,i.dimension)),this._targetWindowId=(0,l.zk)(s).vscodeWindowId,this._rawOptions=F(i),this._validatedOptions=P.validateOptions(this._rawOptions),this.options=this._computeOptions(),this.options.get(13)&&this._containerObserver.startObserving(),this._register(R.D.onDidChangeZoomLevel((()=>this._recomputeOptions()))),this._register(w.M.onDidChangeTabFocus((()=>this._recomputeOptions()))),this._register(this._containerObserver.onDidChange((()=>this._recomputeOptions()))),this._register(C.T.onDidChange((()=>this._recomputeOptions()))),this._register(k.c.getInstance((0,l.zk)(s)).onDidChange((()=>this._recomputeOptions()))),this._register(this._accessibilityService.onDidChangeScreenReaderOptimized((()=>this._recomputeOptions())))}_recomputeOptions(){const e=this._computeOptions(),t=P.checkEquals(this.options,e);null!==t&&(this.options=e,this._onDidChangeFast.fire(t),this._onDidChange.fire(t))}_computeOptions(){const e=this._readEnvConfiguration(),t=T._8.createFromValidatedSettings(this._validatedOptions,e.pixelRatio,this.isSimpleWidget),i=this._readFontInfo(t),s={memory:this._computeOptionsMemory,outerWidth:e.outerWidth,outerHeight:e.outerHeight-this._reservedHeight,fontInfo:i,extraEditorClassName:e.extraEditorClassName,isDominatedByLongLines:this._isDominatedByLongLines,viewLineCount:this._viewLineCount,lineNumbersDigitCount:this._lineNumbersDigitCount,emptySelectionClipboard:e.emptySelectionClipboard,pixelRatio:e.pixelRatio,tabFocusMode:w.M.getTabFocusMode(),accessibilitySupport:e.accessibilitySupport,glyphMarginDecorationLaneCount:this._glyphMarginDecorationLaneCount};return P.computeOptions(this._validatedOptions,s)}_readEnvConfiguration(){return{extraEditorClassName:O(),outerWidth:this._containerObserver.getWidth(),outerHeight:this._containerObserver.getHeight(),emptySelectionClipboard:p.Tc||p.gm,pixelRatio:k.c.getInstance((0,l.ZF)(this._targetWindowId,!0).window).value,accessibilitySupport:this._accessibilityService.isScreenReaderOptimized()?2:this._accessibilityService.getAccessibilitySupport()}}_readFontInfo(e){return C.T.readFontInfo((0,l.ZF)(this._targetWindowId,!0).window,e)}getRawOptions(){return this._rawOptions}updateOptions(e){const t=F(e);P.applyUpdate(this._rawOptions,t)&&(this._validatedOptions=P.validateOptions(this._rawOptions),this._recomputeOptions())}observeContainer(e){this._containerObserver.observe(e)}setIsDominatedByLongLines(e){this._isDominatedByLongLines!==e&&(this._isDominatedByLongLines=e,this._recomputeOptions())}setModelLineCount(e){const t=function(e){let t=0;for(;e;)e=Math.floor(e/10),t++;return t||1}(e);this._lineNumbersDigitCount!==t&&(this._lineNumbersDigitCount=t,this._recomputeOptions())}setViewLineCount(e){this._viewLineCount!==e&&(this._viewLineCount=e,this._recomputeOptions())}setReservedHeight(e){this._reservedHeight!==e&&(this._reservedHeight=e,this._recomputeOptions())}setGlyphMarginDecorationLaneCount(e){this._glyphMarginDecorationLaneCount!==e&&(this._glyphMarginDecorationLaneCount=e,this._recomputeOptions())}};function O(){let e="";return p.nr||p.c8||(e+="no-user-select "),p.nr&&(e+="no-minimap-shadow ",e+="enable-user-select "),_.zx&&(e+="mac "),e}I=A([N(4,x.j)],I);class D{constructor(){this._values=[]}_read(e){return this._values[e]}get(e){return this._values[e]}_write(e,t){this._values[e]=t}}class M{constructor(){this._values=[]}_read(e){if(e>=this._values.length)throw new Error("Cannot read uninitialized value");return this._values[e]}get(e){return this._read(e)}_write(e,t){this._values[e]=t}}class P{static validateOptions(e){const t=new D;for(const i of L.BE){const s="_never_"===i.name?void 0:e[i.name];t._write(i.id,i.validate(s))}return t}static computeOptions(e,t){const i=new M;for(const s of L.BE)i._write(s.id,s.compute(t,i,e._read(s.id)));return i}static _deepEquals(e,t){if("object"!==typeof e||"object"!==typeof t||!e||!t)return e===t;if(Array.isArray(e)||Array.isArray(t))return!(!Array.isArray(e)||!Array.isArray(t))&&m.aI(e,t);if(Object.keys(e).length!==Object.keys(t).length)return!1;for(const i in e)if(!P._deepEquals(e[i],t[i]))return!1;return!0}static checkEquals(e,t){const i=[];let s=!1;for(const n of L.BE){const r=!P._deepEquals(e._read(n.id),t._read(n.id));i[n.id]=r,r&&(s=!0)}return s?new L.lw(i):null}static applyUpdate(e,t){let i=!1;for(const s of L.BE)if(t.hasOwnProperty(s.name)){const n=s.applyUpdate(e[s.name],t[s.name]);e[s.name]=n.newValue,i=i||n.didChange}return i}}function F(e){const t=f.Go(e);return function(e){b.items.forEach((t=>t.apply(e)))}(t),t}var U=i(80301),H=i(55275),B=i(5239),W=i(37734);class V extends d.jG{constructor(){super(),this._shouldRender=!0}shouldRender(){return this._shouldRender}forceShouldRender(){this._shouldRender=!0}setShouldRender(){this._shouldRender=!0}onDidRender(){this._shouldRender=!1}onCompositionStart(e){return!1}onCompositionEnd(e){return!1}onConfigurationChanged(e){return!1}onCursorStateChanged(e){return!1}onDecorationsChanged(e){return!1}onFlushed(e){return!1}onFocusChanged(e){return!1}onLanguageConfigurationChanged(e){return!1}onLineMappingChanged(e){return!1}onLinesChanged(e){return!1}onLinesDeleted(e){return!1}onLinesInserted(e){return!1}onRevealRangeRequest(e){return!1}onScrollChanged(e){return!1}onThemeChanged(e){return!1}onTokensChanged(e){return!1}onTokensColorsChanged(e){return!1}onZonesChanged(e){return!1}handleEvents(e){let t=!1;for(let i=0,s=e.length;i=4&&3===e[0]&&8===e[3]}static isStrictChildOfViewLines(e){return e.length>4&&3===e[0]&&8===e[3]}static isChildOfScrollableElement(e){return e.length>=2&&3===e[0]&&6===e[1]}static isChildOfMinimap(e){return e.length>=2&&3===e[0]&&9===e[1]}static isChildOfContentWidgets(e){return e.length>=4&&3===e[0]&&1===e[3]}static isChildOfOverflowGuard(e){return e.length>=1&&3===e[0]}static isChildOfOverflowingContentWidgets(e){return e.length>=1&&2===e[0]}static isChildOfOverlayWidgets(e){return e.length>=2&&3===e[0]&&4===e[1]}static isChildOfOverflowingOverlayWidgets(e){return e.length>=1&&5===e[0]}}class se{constructor(e,t,i){this.viewModel=e.viewModel;const s=e.configuration.options;this.layoutInfo=s.get(146),this.viewDomNode=t.viewDomNode,this.lineHeight=s.get(67),this.stickyTabStops=s.get(117),this.typicalHalfwidthCharacterWidth=s.get(50).typicalHalfwidthCharacterWidth,this.lastRenderData=i,this._context=e,this._viewHelper=t}getZoneAtCoord(e){return se.getZoneAtCoord(this._context,e)}static getZoneAtCoord(e,t){const i=e.viewLayout.getWhitespaceAtVerticalOffset(t);if(i){const s=i.verticalOffset+i.height/2,n=e.viewModel.getLineCount();let r,o=null,a=null;return i.afterLineNumber!==n&&(a=new Y.y(i.afterLineNumber+1,1)),i.afterLineNumber>0&&(o=new Y.y(i.afterLineNumber,e.viewModel.getLineMaxColumn(i.afterLineNumber))),r=null===a?o:null===o?a:t=e.layoutInfo.glyphMarginLeft,this.isInContentArea=!this.isInMarginArea,this.mouseColumn=Math.max(0,le._getMouseColumn(this.mouseContentHorizontalOffset,e.typicalHalfwidthCharacterWidth))}}class re extends ne{get target(){return this._useHitTestTarget?this.hitTestResult.value.hitTarget:this._eventTarget}get targetPath(){return this._targetPathCacheElement!==this.target&&(this._targetPathCacheElement=this.target,this._targetPathCacheValue=G.collect(this.target,this._ctx.viewDomNode)),this._targetPathCacheValue}constructor(e,t,i,s,n){super(e,t,i,s),this.hitTestResult=new X.d((()=>le.doHitTest(this._ctx,this))),this._targetPathCacheElement=null,this._targetPathCacheValue=new Uint8Array(0),this._ctx=e,this._eventTarget=n;const r=Boolean(this._eventTarget);this._useHitTestTarget=!r}toString(){return`pos(${this.pos.x},${this.pos.y}), editorPos(${this.editorPos.x},${this.editorPos.y}), relativePos(${this.relativePos.x},${this.relativePos.y}), mouseVerticalOffset: ${this.mouseVerticalOffset}, mouseContentHorizontalOffset: ${this.mouseContentHorizontalOffset}\n\ttarget: ${this.target?this.target.outerHTML:null}`}get wouldBenefitFromHitTestTargetSwitch(){return!this._useHitTestTarget&&null!==this.hitTestResult.value.hitTarget&&this.target!==this.hitTestResult.value.hitTarget}switchToHitTestTarget(){this._useHitTestTarget=!0}_getMouseColumn(e=null){return e&&e.columnr.contentLeft+r.width)continue;const i=e.getVerticalOffsetForLineNumber(r.position.lineNumber);if(i<=n&&n<=i+r.height)return t.fulfillContentText(r.position,null,{mightBeForeignElement:!1,injectedText:null})}}return null}static _hitTestViewZone(e,t){const i=e.getZoneAtCoord(t.mouseVerticalOffset);if(i){const e=t.isInContentArea?8:5;return t.fulfillViewZone(e,i.position,i)}return null}static _hitTestTextArea(e,t){return ie.isTextArea(t.targetPath)?e.lastRenderData.lastTextareaPosition?t.fulfillContentText(e.lastRenderData.lastTextareaPosition,null,{mightBeForeignElement:!1,injectedText:null}):t.fulfillTextarea():null}static _hitTestMargin(e,t){if(t.isInMarginArea){const i=e.getFullLineRangeAtCoord(t.mouseVerticalOffset),s=i.range.getStartPosition();let n=Math.abs(t.relativePos.x);const r={isAfterLines:i.isAfterLines,glyphMarginLeft:e.layoutInfo.glyphMarginLeft,glyphMarginWidth:e.layoutInfo.glyphMarginWidth,lineNumbersWidth:e.layoutInfo.lineNumbersWidth,offsetX:n};if(n-=e.layoutInfo.glyphMarginLeft,n<=e.layoutInfo.glyphMarginWidth){const o=e.viewModel.coordinatesConverter.convertViewPositionToModelPosition(i.range.getStartPosition()),a=e.viewModel.glyphLanes.getLanesAtLine(o.lineNumber);return r.glyphMarginLane=a[Math.floor(n/e.lineHeight)],t.fulfillMargin(2,s,i.range,r)}return n-=e.layoutInfo.glyphMarginWidth,n<=e.layoutInfo.lineNumbersWidth?t.fulfillMargin(3,s,i.range,r):(n-=e.layoutInfo.lineNumbersWidth,t.fulfillMargin(4,s,i.range,r))}return null}static _hitTestViewLines(e,t){if(!ie.isChildOfViewLines(t.targetPath))return null;if(e.isInTopPadding(t.mouseVerticalOffset))return t.fulfillContentEmpty(new Y.y(1,1),oe);if(e.isAfterLines(t.mouseVerticalOffset)||e.isInBottomPadding(t.mouseVerticalOffset)){const i=e.viewModel.getLineCount(),s=e.viewModel.getLineMaxColumn(i);return t.fulfillContentEmpty(new Y.y(i,s),oe)}if(ie.isStrictChildOfViewLines(t.targetPath)){const i=e.getLineNumberAtVerticalOffset(t.mouseVerticalOffset);if(0===e.viewModel.getLineLength(i)){const s=e.getLineWidth(i),n=ae(t.mouseContentHorizontalOffset-s);return t.fulfillContentEmpty(new Y.y(i,1),n)}const s=e.getLineWidth(i);if(t.mouseContentHorizontalOffset>=s){const n=ae(t.mouseContentHorizontalOffset-s),r=new Y.y(i,e.viewModel.getLineMaxColumn(i));return t.fulfillContentEmpty(r,n)}}const i=t.hitTestResult.value;return 1===i.type?le.createMouseTargetFromHitTestPosition(e,t,i.spanNode,i.position,i.injectedText):t.wouldBenefitFromHitTestTargetSwitch?(t.switchToHitTestTarget(),this._createMouseTarget(e,t)):t.fulfillUnknown()}static _hitTestMinimap(e,t){if(ie.isChildOfMinimap(t.targetPath)){const i=e.getLineNumberAtVerticalOffset(t.mouseVerticalOffset),s=e.viewModel.getLineMaxColumn(i);return t.fulfillScrollbar(new Y.y(i,s))}return null}static _hitTestScrollbarSlider(e,t){if(ie.isChildOfScrollableElement(t.targetPath)&&t.target&&1===t.target.nodeType){const i=t.target.className;if(i&&/\b(slider|scrollbar)\b/.test(i)){const i=e.getLineNumberAtVerticalOffset(t.mouseVerticalOffset),s=e.viewModel.getLineMaxColumn(i);return t.fulfillScrollbar(new Y.y(i,s))}}return null}static _hitTestScrollbar(e,t){if(ie.isChildOfScrollableElement(t.targetPath)){const i=e.getLineNumberAtVerticalOffset(t.mouseVerticalOffset),s=e.viewModel.getLineMaxColumn(i);return t.fulfillScrollbar(new Y.y(i,s))}return null}getMouseColumn(e){const t=this._context.configuration.options,i=t.get(146),s=this._context.viewLayout.getCurrentScrollLeft()+e.x-i.contentLeft;return le._getMouseColumn(s,t.get(50).typicalHalfwidthCharacterWidth)}static _getMouseColumn(e,t){if(e<0)return 1;return Math.round(e/t)+1}static createMouseTargetFromHitTestPosition(e,t,i,s,n){const r=s.lineNumber,o=s.column,a=e.getLineWidth(r);if(t.mouseContentHorizontalOffset>a){const e=ae(t.mouseContentHorizontalOffset-a);return t.fulfillContentEmpty(s,e)}const c=e.visibleRangeForPosition(r,o);if(!c)return t.fulfillUnknown(s);const h=c.left;if(Math.abs(t.mouseContentHorizontalOffset-h)<1)return t.fulfillContentText(s,null,{mightBeForeignElement:!!n,injectedText:n});const d=[];if(d.push({offset:c.left,column:o}),o>1){const t=e.visibleRangeForPosition(r,o-1);t&&d.push({offset:t.left,column:o-1})}if(oe.offset-t.offset));const u=t.pos.toClientCoordinates(l.zk(e.viewDomNode)),g=i.getBoundingClientRect(),p=g.left<=u.clientX&&u.clientX<=g.right;let m=null;for(let l=1;ln)){const i=Math.floor((s+n)/2);let r=t.pos.y+(i-t.mouseVerticalOffset);r<=t.editorPos.y&&(r=t.editorPos.y+1),r>=t.editorPos.y+t.editorPos.height&&(r=t.editorPos.y+t.editorPos.height-1);const o=new W.nz(t.pos.x,r),a=this._actualDoHitTestWithCaretRangeFromPoint(e,o.toClientCoordinates(l.zk(e.viewDomNode)));if(1===a.type)return a}return this._actualDoHitTestWithCaretRangeFromPoint(e,t.pos.toClientCoordinates(l.zk(e.viewDomNode)))}static _actualDoHitTestWithCaretRangeFromPoint(e,t){const i=l.jG(e.viewDomNode);let s;if(s=i?"undefined"===typeof i.caretRangeFromPoint?function(e,t,i){const s=document.createRange();let n=e.elementFromPoint(t,i);if(null!==n){for(;n&&n.firstChild&&n.firstChild.nodeType!==n.firstChild.TEXT_NODE&&n.lastChild&&n.lastChild.firstChild;)n=n.lastChild;const e=n.getBoundingClientRect(),i=l.zk(n),r=`${i.getComputedStyle(n,null).getPropertyValue("font-style")} ${i.getComputedStyle(n,null).getPropertyValue("font-variant")} ${i.getComputedStyle(n,null).getPropertyValue("font-weight")} ${i.getComputedStyle(n,null).getPropertyValue("font-size")}/${i.getComputedStyle(n,null).getPropertyValue("line-height")} ${i.getComputedStyle(n,null).getPropertyValue("font-family")}`,o=n.innerText;let a,c=e.left,h=0;if(t>e.left+e.width)h=o.length;else{const e=ce.getInstance();for(let i=0;ithis._createMouseTarget(e,t)),(e=>this._getMouseColumn(e)))),this.lastMouseLeaveTime=-1,this._height=this._context.configuration.options.get(146).height;const s=new W.$z(this.viewHelper.viewDomNode);this._register(s.onContextMenu(this.viewHelper.viewDomNode,(e=>this._onContextMenu(e,!0)))),this._register(s.onMouseMove(this.viewHelper.viewDomNode,(e=>{this._onMouseMove(e),this._mouseLeaveMonitor||(this._mouseLeaveMonitor=l.ko(this.viewHelper.viewDomNode.ownerDocument,"mousemove",(e=>{this.viewHelper.viewDomNode.contains(e.target)||this._onMouseLeave(new W.dO(e,!1,this.viewHelper.viewDomNode))})))}))),this._register(s.onMouseUp(this.viewHelper.viewDomNode,(e=>this._onMouseUp(e)))),this._register(s.onMouseLeave(this.viewHelper.viewDomNode,(e=>this._onMouseLeave(e))));let n=0;this._register(s.onPointerDown(this.viewHelper.viewDomNode,((e,t)=>{n=t}))),this._register(l.ko(this.viewHelper.viewDomNode,l.Bx.POINTER_UP,(e=>{this._mouseDownOperation.onPointerUp()}))),this._register(s.onMouseDown(this.viewHelper.viewDomNode,(e=>this._onMouseDown(e,n)))),this._setupMouseWheelZoomListener(),this._context.addEventHandler(this)}_setupMouseWheelZoomListener(){const e=me.QC.INSTANCE;let t=0,i=R.D.getZoomLevel(),s=!1,n=0;function r(e){return _.zx?(e.metaKey||e.ctrlKey)&&!e.shiftKey&&!e.altKey:e.ctrlKey&&!e.metaKey&&!e.shiftKey&&!e.altKey}this._register(l.ko(this.viewHelper.viewDomNode,l.Bx.MOUSE_WHEEL,(o=>{if(this.viewController.emitMouseWheel(o),!this._context.configuration.options.get(76))return;const a=new ge.$(o);if(e.acceptStandardWheelEvent(a),e.isPhysicalMouseWheel()){if(r(o)){const e=R.D.getZoomLevel(),t=a.deltaY>0?1:-1;R.D.setZoomLevel(e+t),a.preventDefault(),a.stopPropagation()}}else Date.now()-t>50&&(i=R.D.getZoomLevel(),s=r(o),n=0),t=Date.now(),n+=a.deltaY,s&&(R.D.setZoomLevel(i+n/5),a.preventDefault(),a.stopPropagation())}),{capture:!0,passive:!1}))}dispose(){this._context.removeEventHandler(this),this._mouseLeaveMonitor&&(this._mouseLeaveMonitor.dispose(),this._mouseLeaveMonitor=null),super.dispose()}onConfigurationChanged(e){if(e.hasChanged(146)){const e=this._context.configuration.options.get(146).height;this._height!==e&&(this._height=e,this._mouseDownOperation.onHeightChanged())}return!1}onCursorStateChanged(e){return this._mouseDownOperation.onCursorStateChanged(e),!1}onFocusChanged(e){return!1}getTargetAtClientPoint(e,t){const i=new W.Hh(e,t).toPageCoordinates(l.zk(this.viewHelper.viewDomNode)),s=(0,W.wt)(this.viewHelper.viewDomNode);if(i.ys.y+s.height||i.xs.x+s.width)return null;const n=(0,W.i_)(this.viewHelper.viewDomNode,s,i);return this.mouseTargetFactory.createMouseTarget(this.viewHelper.getLastRenderData(),s,i,n,null)}_createMouseTarget(e,t){let i=e.target;if(!this.viewHelper.viewDomNode.contains(i)){const t=l.jG(this.viewHelper.viewDomNode);t&&(i=t.elementsFromPoint(e.posx,e.posy).find((e=>this.viewHelper.viewDomNode.contains(e))))}return this.mouseTargetFactory.createMouseTarget(this.viewHelper.getLastRenderData(),e.editorPos,e.pos,e.relativePos,t?i:null)}_getMouseColumn(e){return this.mouseTargetFactory.getMouseColumn(e.relativePos)}_onContextMenu(e,t){this.viewController.emitContextMenu({event:e,target:this._createMouseTarget(e,t)})}_onMouseMove(e){if(this.mouseTargetFactory.mouseTargetIsWidget(e)||e.preventDefault(),this._mouseDownOperation.isActive())return;e.timestamp{e.preventDefault(),this.viewHelper.focusTextArea()};if(c&&(s||r&&o))h(),this._mouseDownOperation.start(i.type,e,t);else if(n)e.preventDefault();else if(a){const s=i.detail;c&&this.viewHelper.shouldSuppressMouseDownOnViewZone(s.viewZoneId)&&(h(),this._mouseDownOperation.start(i.type,e,t),e.preventDefault())}else l&&this.viewHelper.shouldSuppressMouseDownOnWidget(i.detail)&&(h(),e.preventDefault());this.viewController.emitMouseDown({event:e,target:i})}}class _e extends d.jG{constructor(e,t,i,s,n,r){super(),this._context=e,this._viewController=t,this._viewHelper=i,this._mouseTargetFactory=s,this._createMouseTarget=n,this._getMouseColumn=r,this._mouseMoveMonitor=this._register(new W.BA(this._viewHelper.viewDomNode)),this._topBottomDragScrolling=this._register(new ve(this._context,this._viewHelper,this._mouseTargetFactory,((e,t,i)=>this._dispatchMouse(e,t,i)))),this._mouseState=new be,this._currentSelection=new pe.L(1,1,1,1),this._isActive=!1,this._lastMouseEvent=null}dispose(){super.dispose()}isActive(){return this._isActive}_onMouseDownThenMove(e){this._lastMouseEvent=e,this._mouseState.setModifiers(e);const t=this._findMousePosition(e,!1);t&&(this._mouseState.isDragAndDrop?this._viewController.emitMouseDrag({event:e,target:t}):13!==t.type||"above"!==t.outsidePosition&&"below"!==t.outsidePosition?(this._topBottomDragScrolling.stop(),this._dispatchMouse(t,!0,1)):this._topBottomDragScrolling.start(t,e))}start(e,t,i){this._lastMouseEvent=t,this._mouseState.setStartedOnLineNumbers(3===e),this._mouseState.setStartButtons(t),this._mouseState.setModifiers(t);const s=this._findMousePosition(t,!0);if(!s||!s.position)return;this._mouseState.trySetCount(t.detail,s.position),t.detail=this._mouseState.count;const n=this._context.configuration.options;if(!n.get(92)&&n.get(35)&&!n.get(22)&&!this._mouseState.altKey&&t.detail<2&&!this._isActive&&!this._currentSelection.isEmpty()&&6===s.type&&s.position&&this._currentSelection.containsPosition(s.position))return this._mouseState.isDragAndDrop=!0,this._isActive=!0,void this._mouseMoveMonitor.startMonitoring(this._viewHelper.viewLinesDomNode,i,t.buttons,(e=>this._onMouseDownThenMove(e)),(e=>{const t=this._findMousePosition(this._lastMouseEvent,!1);l.kx(e)?this._viewController.emitMouseDropCanceled():this._viewController.emitMouseDrop({event:this._lastMouseEvent,target:t?this._createMouseTarget(this._lastMouseEvent,!0):null}),this._stop()}));this._mouseState.isDragAndDrop=!1,this._dispatchMouse(s,t.shiftKey,1),this._isActive||(this._isActive=!0,this._mouseMoveMonitor.startMonitoring(this._viewHelper.viewLinesDomNode,i,t.buttons,(e=>this._onMouseDownThenMove(e)),(()=>this._stop())))}_stop(){this._isActive=!1,this._topBottomDragScrolling.stop()}onHeightChanged(){this._mouseMoveMonitor.stopMonitoring()}onPointerUp(){this._mouseMoveMonitor.stopMonitoring()}onCursorStateChanged(e){this._currentSelection=e.selections[0]}_getPositionOutsideEditor(e){const t=e.editorPos,i=this._context.viewModel,s=this._context.viewLayout,n=this._getMouseColumn(e);if(e.posyt.y+t.height){const r=e.posy-t.y-t.height,o=s.getCurrentScrollTop()+e.relativePos.y,a=se.getZoneAtCoord(this._context,o);if(a){const e=this._helpPositionJumpOverViewZone(a);if(e)return te.createOutsideEditor(n,e,"below",r)}const l=s.getLineNumberAtVerticalOffset(o);return te.createOutsideEditor(n,new Y.y(l,i.getLineMaxColumn(l)),"below",r)}const r=s.getLineNumberAtVerticalOffset(s.getCurrentScrollTop()+e.relativePos.y);if(e.posxt.x+t.width){const s=e.posx-t.x-t.width;return te.createOutsideEditor(n,new Y.y(r,i.getLineMaxColumn(r)),"right",s)}return null}_findMousePosition(e,t){const i=this._getPositionOutsideEditor(e);if(i)return i;const s=this._createMouseTarget(e,t);if(!s.position)return null;if(8===s.type||5===s.type){const e=this._helpPositionJumpOverViewZone(s.detail);if(e)return te.createViewZone(s.type,s.element,s.mouseColumn,e,s.detail)}return s}_helpPositionJumpOverViewZone(e){const t=new Y.y(this._currentSelection.selectionStartLineNumber,this._currentSelection.selectionStartColumn),i=e.positionBefore,s=e.positionAfter;return i&&s?i.isBefore(t)?i:s:null}_dispatchMouse(e,t,i){e.position&&this._viewController.dispatchMouse({position:e.position,mouseColumn:e.mouseColumn,startedOnLineNumbers:this._mouseState.startedOnLineNumbers,revealType:i,inSelectionMode:t,mouseDownCount:this._mouseState.count,altKey:this._mouseState.altKey,ctrlKey:this._mouseState.ctrlKey,metaKey:this._mouseState.metaKey,shiftKey:this._mouseState.shiftKey,leftButton:this._mouseState.leftButton,middleButton:this._mouseState.middleButton,onInjectedText:6===e.type&&null!==e.detail.injectedText})}}class ve extends d.jG{constructor(e,t,i,s){super(),this._context=e,this._viewHelper=t,this._mouseTargetFactory=i,this._dispatchMouse=s,this._operation=null}dispose(){super.dispose(),this.stop()}start(e,t){this._operation?this._operation.setPosition(e,t):this._operation=new Ce(this._context,this._viewHelper,this._mouseTargetFactory,this._dispatchMouse,e,t)}stop(){this._operation&&(this._operation.dispose(),this._operation=null)}}class Ce extends d.jG{constructor(e,t,i,s,n,r){super(),this._context=e,this._viewHelper=t,this._mouseTargetFactory=i,this._dispatchMouse=s,this._position=n,this._mouseEvent=r,this._lastTime=Date.now(),this._animationFrameDisposable=l.PG(l.zk(r.browserEvent),(()=>this._execute()))}dispose(){this._animationFrameDisposable.dispose(),super.dispose()}setPosition(e,t){this._position=e,this._mouseEvent=t}_tick(){const e=Date.now(),t=e-this._lastTime;return this._lastTime=e,t}_getScrollSpeed(){const e=this._context.configuration.options.get(67),t=this._context.configuration.options.get(146).height/e,i=this._position.outsideDistance/e;return i<=1.5?Math.max(30,t*(1+i)):i<=3?Math.max(60,t*(2+i)):Math.max(200,t*(7+i))}_execute(){const e=this._context.configuration.options.get(67),t=this._getScrollSpeed()*(this._tick()/1e3)*e,i="above"===this._position.outsidePosition?-t:t;this._context.viewModel.viewLayout.deltaScrollNow(0,i),this._viewHelper.renderNow();const s=this._context.viewLayout.getLinesViewportData(),n="above"===this._position.outsidePosition?s.startLineNumber:s.endLineNumber;let r;{const e=(0,W.wt)(this._viewHelper.viewDomNode),t=this._context.configuration.options.get(146).horizontalScrollbarHeight,i=new W.nz(this._mouseEvent.pos.x,e.y+e.height-t-.1),s=(0,W.i_)(this._viewHelper.viewDomNode,e,i);r=this._mouseTargetFactory.createMouseTarget(this._viewHelper.getLastRenderData(),e,i,s,null)}r.position&&r.position.lineNumber===n||(r="above"===this._position.outsidePosition?te.createOutsideEditor(this._position.mouseColumn,new Y.y(n,1),"above",this._position.outsideDistance):te.createOutsideEditor(this._position.mouseColumn,new Y.y(n,this._context.viewModel.getLineMaxColumn(n)),"below",this._position.outsideDistance)),this._dispatchMouse(r,!0,2),this._animationFrameDisposable=l.PG(l.zk(r.element),(()=>this._execute()))}}class be{static{this.CLEAR_MOUSE_DOWN_COUNT_TIME=400}get altKey(){return this._altKey}get ctrlKey(){return this._ctrlKey}get metaKey(){return this._metaKey}get shiftKey(){return this._shiftKey}get leftButton(){return this._leftButton}get middleButton(){return this._middleButton}get startedOnLineNumbers(){return this._startedOnLineNumbers}constructor(){this._altKey=!1,this._ctrlKey=!1,this._metaKey=!1,this._shiftKey=!1,this._leftButton=!1,this._middleButton=!1,this._startedOnLineNumbers=!1,this._lastMouseDownPosition=null,this._lastMouseDownPositionEqualCount=0,this._lastMouseDownCount=0,this._lastSetMouseDownCountTime=0,this.isDragAndDrop=!1}get count(){return this._lastMouseDownCount}setModifiers(e){this._altKey=e.altKey,this._ctrlKey=e.ctrlKey,this._metaKey=e.metaKey,this._shiftKey=e.shiftKey}setStartButtons(e){this._leftButton=e.leftButton,this._middleButton=e.middleButton}setStartedOnLineNumbers(e){this._startedOnLineNumbers=e}trySetCount(e,t){const i=(new Date).getTime();i-this._lastSetMouseDownCountTime>be.CLEAR_MOUSE_DOWN_COUNT_TIME&&(e=1),this._lastSetMouseDownCountTime=i,e>this._lastMouseDownCount+1&&(e=this._lastMouseDownCount+1),this._lastMouseDownPosition&&this._lastMouseDownPosition.equals(t)?this._lastMouseDownPositionEqualCount++:this._lastMouseDownPositionEqualCount=1,this._lastMouseDownPosition=t,this._lastMouseDownCount=Math.min(e,this._lastMouseDownPositionEqualCount)}}var Ee=i(68792);class Se extends fe{constructor(e,t,i){super(e,t,i),this._register(de.q.addTarget(this.viewHelper.linesContentDomNode)),this._register(l.ko(this.viewHelper.linesContentDomNode,de.B.Tap,(e=>this.onTap(e)))),this._register(l.ko(this.viewHelper.linesContentDomNode,de.B.Change,(e=>this.onChange(e)))),this._register(l.ko(this.viewHelper.linesContentDomNode,de.B.Contextmenu,(e=>this._onContextMenu(new W.dO(e,!1,this.viewHelper.viewDomNode),!1)))),this._lastPointerType="mouse",this._register(l.ko(this.viewHelper.linesContentDomNode,"pointerdown",(e=>{const t=e.pointerType;this._lastPointerType="mouse"!==t?"touch"===t?"touch":"pen":"mouse"})));const s=new W.DW(this.viewHelper.viewDomNode);this._register(s.onPointerMove(this.viewHelper.viewDomNode,(e=>this._onMouseMove(e)))),this._register(s.onPointerUp(this.viewHelper.viewDomNode,(e=>this._onMouseUp(e)))),this._register(s.onPointerLeave(this.viewHelper.viewDomNode,(e=>this._onMouseLeave(e)))),this._register(s.onPointerDown(this.viewHelper.viewDomNode,((e,t)=>this._onMouseDown(e,t))))}onTap(e){e.initialTarget&&this.viewHelper.linesContentDomNode.contains(e.initialTarget)&&(e.preventDefault(),this.viewHelper.focusTextArea(),this._dispatchGesture(e,!1))}onChange(e){"touch"===this._lastPointerType&&this._context.viewModel.viewLayout.deltaScrollNow(-e.translationX,-e.translationY),"pen"===this._lastPointerType&&this._dispatchGesture(e,!0)}_dispatchGesture(e,t){const i=this._createMouseTarget(new W.dO(e,!1,this.viewHelper.viewDomNode),!1);i.position&&this.viewController.dispatchMouse({position:i.position,mouseColumn:i.position.column,startedOnLineNumbers:!1,revealType:1,mouseDownCount:e.tapCount,inSelectionMode:t,altKey:!1,ctrlKey:!1,metaKey:!1,shiftKey:!1,leftButton:!1,middleButton:!1,onInjectedText:6===i.type&&null!==i.detail.injectedText})}_onMouseDown(e,t){"touch"!==e.browserEvent.pointerType&&super._onMouseDown(e,t)}}class ye extends fe{constructor(e,t,i){super(e,t,i),this._register(de.q.addTarget(this.viewHelper.linesContentDomNode)),this._register(l.ko(this.viewHelper.linesContentDomNode,de.B.Tap,(e=>this.onTap(e)))),this._register(l.ko(this.viewHelper.linesContentDomNode,de.B.Change,(e=>this.onChange(e)))),this._register(l.ko(this.viewHelper.linesContentDomNode,de.B.Contextmenu,(e=>this._onContextMenu(new W.dO(e,!1,this.viewHelper.viewDomNode),!1))))}onTap(e){e.preventDefault(),this.viewHelper.focusTextArea();const t=this._createMouseTarget(new W.dO(e,!1,this.viewHelper.viewDomNode),!1);if(t.position){const e=document.createEvent("CustomEvent");e.initEvent(Ee.$D.Tap,!1,!0),this.viewHelper.dispatchTextAreaEvent(e),this.viewController.moveTo(t.position,1)}}onChange(e){this._context.viewModel.viewLayout.deltaScrollNow(-e.translationX,-e.translationY)}}class we extends d.jG{constructor(e,t,i){super();(_.un||_.m0&&_.Fr)&&he.e.pointerEvents?this.handler=this._register(new Se(e,t,i)):ue.G.TouchEvent?this.handler=this._register(new ye(e,t,i)):this.handler=this._register(new fe(e,t,i))}getTargetAtClientPoint(e,t){return this.handler.getTargetAtClientPoint(e,t)}}var Le=i(78209),Re=i(91508),Te=i(69785);class xe extends V{}var ke=i(47612),Ae=i(87119);class Ne extends xe{static{this.CLASS_NAME="line-numbers"}constructor(e){super(),this._context=e,this._readConfig(),this._lastCursorModelPosition=new Y.y(1,1),this._renderResult=null,this._activeLineNumber=1,this._context.addEventHandler(this)}_readConfig(){const e=this._context.configuration.options;this._lineHeight=e.get(67);const t=e.get(68);this._renderLineNumbers=t.renderType,this._renderCustomLineNumbers=t.renderFn,this._renderFinalNewline=e.get(96);const i=e.get(146);this._lineNumbersLeft=i.lineNumbersLeft,this._lineNumbersWidth=i.lineNumbersWidth}dispose(){this._context.removeEventHandler(this),this._renderResult=null,super.dispose()}onConfigurationChanged(e){return this._readConfig(),!0}onCursorStateChanged(e){const t=e.selections[0].getPosition();this._lastCursorModelPosition=this._context.viewModel.coordinatesConverter.convertViewPositionToModelPosition(t);let i=!1;return this._activeLineNumber!==t.lineNumber&&(this._activeLineNumber=t.lineNumber,i=!0),2!==this._renderLineNumbers&&3!==this._renderLineNumbers||(i=!0),i}onFlushed(e){return!0}onLinesChanged(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return e.scrollTopChanged}onZonesChanged(e){return!0}onDecorationsChanged(e){return e.affectsLineNumber}_getLineRenderLineNumber(e){const t=this._context.viewModel.coordinatesConverter.convertViewPositionToModelPosition(new Y.y(e,1));if(1!==t.column)return"";const i=t.lineNumber;if(this._renderCustomLineNumbers)return this._renderCustomLineNumbers(i);if(2===this._renderLineNumbers){const e=Math.abs(this._lastCursorModelPosition.lineNumber-i);return 0===e?''+i+"":String(e)}if(3===this._renderLineNumbers){if(this._lastCursorModelPosition.lineNumber===i)return String(i);if(i%10===0)return String(i);return i===this._context.viewModel.getLineCount()?String(i):""}return String(i)}prepareRender(e){if(0===this._renderLineNumbers)return void(this._renderResult=null);const t=_.j9?this._lineHeight%2===0?" lh-even":" lh-odd":"",i=e.visibleRange.startLineNumber,s=e.visibleRange.endLineNumber,n=this._context.viewModel.getDecorationsInViewport(e.visibleRange).filter((e=>!!e.options.lineNumberClassName));n.sort(((e,t)=>q.Q.compareRangesUsingEnds(e.range,t.range)));let r=0;const o=this._context.viewModel.getLineCount(),a=[];for(let l=i;l<=s;l++){const e=l-i;let s=this._getLineRenderLineNumber(l),c="";for(;r${s}`):a[e]=""}this._renderResult=a}render(e,t){if(!this._renderResult)return"";const i=t-e;return i<0||i>=this._renderResult.length?"":this._renderResult[i]}}(0,ke.zy)(((e,t)=>{const i=e.getColor(Ae.Qt),s=e.getColor(Ae.JB);s?t.addRule(`.monaco-editor .line-numbers.dimmed-line-number { color: ${s}; }`):i&&t.addRule(`.monaco-editor .line-numbers.dimmed-line-number { color: ${i.transparent(.4)}; }`)}));class Ie extends z{static{this.CLASS_NAME="glyph-margin"}static{this.OUTER_CLASS_NAME="margin"}constructor(e){super(e);const t=this._context.configuration.options,i=t.get(146);this._canUseLayerHinting=!t.get(32),this._contentLeft=i.contentLeft,this._glyphMarginLeft=i.glyphMarginLeft,this._glyphMarginWidth=i.glyphMarginWidth,this._domNode=(0,H.Z)(document.createElement("div")),this._domNode.setClassName(Ie.OUTER_CLASS_NAME),this._domNode.setPosition("absolute"),this._domNode.setAttribute("role","presentation"),this._domNode.setAttribute("aria-hidden","true"),this._glyphMarginBackgroundDomNode=(0,H.Z)(document.createElement("div")),this._glyphMarginBackgroundDomNode.setClassName(Ie.CLASS_NAME),this._domNode.appendChild(this._glyphMarginBackgroundDomNode)}dispose(){super.dispose()}getDomNode(){return this._domNode}onConfigurationChanged(e){const t=this._context.configuration.options,i=t.get(146);return this._canUseLayerHinting=!t.get(32),this._contentLeft=i.contentLeft,this._glyphMarginLeft=i.glyphMarginLeft,this._glyphMarginWidth=i.glyphMarginWidth,!0}onScrollChanged(e){return super.onScrollChanged(e)||e.scrollTopChanged}prepareRender(e){}render(e){this._domNode.setLayerHinting(this._canUseLayerHinting),this._domNode.setContain("strict");const t=e.scrollTop-e.bigNumbersDelta;this._domNode.setTop(-t);const i=Math.min(e.scrollHeight,1e6);this._domNode.setHeight(i),this._domNode.setWidth(this._contentLeft),this._glyphMarginBackgroundDomNode.setLeft(this._glyphMarginLeft),this._glyphMarginBackgroundDomNode.setWidth(this._glyphMarginWidth),this._glyphMarginBackgroundDomNode.setHeight(i)}}var Oe=i(81782);const De="monaco-mouse-cursor-text";var Me=i(62083),Pe=i(47661),Fe=i(2299),Ue=i(98031),He=i(63591),Be=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},We=function(e,t){return function(i,s){t(i,s,e)}};class Ve{constructor(e,t,i,s,n){this._context=e,this.modelLineNumber=t,this.distanceToModelLineStart=i,this.widthOfHiddenLineTextBefore=s,this.distanceToModelLineEnd=n,this._visibleTextAreaBrand=void 0,this.startPosition=null,this.endPosition=null,this.visibleTextareaStart=null,this.visibleTextareaEnd=null,this._previousPresentation=null}prepareRender(e){const t=new Y.y(this.modelLineNumber,this.distanceToModelLineStart+1),i=new Y.y(this.modelLineNumber,this._context.viewModel.model.getLineMaxColumn(this.modelLineNumber)-this.distanceToModelLineEnd);this.startPosition=this._context.viewModel.coordinatesConverter.convertModelPositionToViewPosition(t),this.endPosition=this._context.viewModel.coordinatesConverter.convertModelPositionToViewPosition(i),this.startPosition.lineNumber===this.endPosition.lineNumber?(this.visibleTextareaStart=e.visibleRangeForPosition(this.startPosition),this.visibleTextareaEnd=e.visibleRangeForPosition(this.endPosition)):(this.visibleTextareaStart=null,this.visibleTextareaEnd=null)}definePresentation(e){return this._previousPresentation||(this._previousPresentation=e||{foreground:1,italic:!1,bold:!1,underline:!1,strikethrough:!1}),this._previousPresentation}}const ze=p.gm;let Ge=class extends z{constructor(e,t,i,s,n){super(e),this._keybindingService=s,this._instantiationService=n,this._primaryCursorPosition=new Y.y(1,1),this._primaryCursorVisibleRange=null,this._viewController=t,this._visibleRangeProvider=i,this._scrollLeft=0,this._scrollTop=0;const r=this._context.configuration.options,o=r.get(146);this._setAccessibilityOptions(r),this._contentLeft=o.contentLeft,this._contentWidth=o.contentWidth,this._contentHeight=o.height,this._fontInfo=r.get(50),this._lineHeight=r.get(67),this._emptySelectionClipboard=r.get(37),this._copyWithSyntaxHighlighting=r.get(25),this._visibleTextArea=null,this._selections=[new pe.L(1,1,1,1)],this._modelSelections=[new pe.L(1,1,1,1)],this._lastRenderPosition=null,this.textArea=(0,H.Z)(document.createElement("textarea")),G.write(this.textArea,7),this.textArea.setClassName(`inputarea ${De}`),this.textArea.setAttribute("wrap",this._textAreaWrapping&&!this._visibleTextArea?"on":"off");const{tabSize:a}=this._context.viewModel.model.getOptions();this.textArea.domNode.style.tabSize=a*this._fontInfo.spaceWidth+"px",this.textArea.setAttribute("autocorrect","off"),this.textArea.setAttribute("autocapitalize","off"),this.textArea.setAttribute("autocomplete","off"),this.textArea.setAttribute("spellcheck","false"),this.textArea.setAttribute("aria-label",this._getAriaLabel(r)),this.textArea.setAttribute("aria-required",r.get(5)?"true":"false"),this.textArea.setAttribute("tabindex",String(r.get(125))),this.textArea.setAttribute("role","textbox"),this.textArea.setAttribute("aria-roledescription",Le.kg("editor","editor")),this.textArea.setAttribute("aria-multiline","true"),this.textArea.setAttribute("aria-autocomplete",r.get(92)?"none":"both"),this._ensureReadOnlyAttribute(),this.textAreaCover=(0,H.Z)(document.createElement("div")),this.textAreaCover.setPosition("absolute");const l={getLineCount:()=>this._context.viewModel.getLineCount(),getLineMaxColumn:e=>this._context.viewModel.getLineMaxColumn(e),getValueInRange:(e,t)=>this._context.viewModel.getValueInRange(e,t),getValueLengthInRange:(e,t)=>this._context.viewModel.getValueLengthInRange(e,t),modifyPosition:(e,t)=>this._context.viewModel.modifyPosition(e,t)},c={getDataToCopy:()=>{const e=this._context.viewModel.getPlainTextToCopy(this._modelSelections,this._emptySelectionClipboard,_.uF),t=this._context.viewModel.model.getEOL(),i=this._emptySelectionClipboard&&1===this._modelSelections.length&&this._modelSelections[0].isEmpty(),s=Array.isArray(e)?e:null,n=Array.isArray(e)?e.join(t):e;let r,o=null;if(Ee.Eq.forceCopyWithSyntaxHighlighting||this._copyWithSyntaxHighlighting&&n.length<65536){const e=this._context.viewModel.getRichTextToCopy(this._modelSelections,this._emptySelectionClipboard);e&&(r=e.html,o=e.mode)}return{isFromEmptySelection:i,multicursorText:s,text:n,html:r,mode:o}},getScreenReaderContent:()=>{if(1===this._accessibilitySupport){const e=this._selections[0];if(_.zx&&e.isEmpty()){const t=e.getStartPosition();let i=this._getWordBeforePosition(t);if(0===i.length&&(i=this._getCharacterBeforePosition(t)),i.length>0)return new Te._O(i,i.length,i.length,q.Q.fromPositions(t),0)}const t=500;if(_.zx&&!e.isEmpty()&&l.getValueLengthInRange(e,0)0)return new Te._O(i,s,s,q.Q.fromPositions(t),0)}return Te._O.EMPTY}return Te.Al.fromEditorSelection(l,this._selections[0],this._accessibilityPageSize,0===this._accessibilitySupport)},deduceModelPosition:(e,t,i)=>this._context.viewModel.deduceModelPositionRelativeToViewPosition(e,t,i)},h=this._register(new Ee.M0(this.textArea.domNode));this._textAreaInput=this._register(this._instantiationService.createInstance(Ee.No,c,h,_.OS,{isAndroid:p.m0,isChrome:p.H8,isFirefox:p.gm,isSafari:p.nr})),this._register(this._textAreaInput.onKeyDown((e=>{this._viewController.emitKeyDown(e)}))),this._register(this._textAreaInput.onKeyUp((e=>{this._viewController.emitKeyUp(e)}))),this._register(this._textAreaInput.onPaste((e=>{let t=!1,i=null,s=null;e.metadata&&(t=this._emptySelectionClipboard&&!!e.metadata.isFromEmptySelection,i="undefined"!==typeof e.metadata.multicursorText?e.metadata.multicursorText:null,s=e.metadata.mode),this._viewController.paste(e.text,t,i,s)}))),this._register(this._textAreaInput.onCut((()=>{this._viewController.cut()}))),this._register(this._textAreaInput.onType((e=>{e.replacePrevCharCnt||e.replaceNextCharCnt||e.positionDelta?(Te.Hf&&console.log(` => compositionType: <<${e.text}>>, ${e.replacePrevCharCnt}, ${e.replaceNextCharCnt}, ${e.positionDelta}`),this._viewController.compositionType(e.text,e.replacePrevCharCnt,e.replaceNextCharCnt,e.positionDelta)):(Te.Hf&&console.log(` => type: <<${e.text}>>`),this._viewController.type(e.text))}))),this._register(this._textAreaInput.onSelectionChangeRequest((e=>{this._viewController.setSelection(e)}))),this._register(this._textAreaInput.onCompositionStart((e=>{const t=this.textArea.domNode,i=this._modelSelections[0],{distanceToModelLineStart:s,widthOfHiddenTextBefore:n}=(()=>{const e=t.value.substring(0,Math.min(t.selectionStart,t.selectionEnd)),s=e.lastIndexOf("\n"),n=e.substring(s+1),r=n.lastIndexOf("\t"),o=n.length-r-1,a=i.getStartPosition(),l=Math.min(a.column-1,o),c=a.column-1-l,h=n.substring(0,n.length-l),{tabSize:d}=this._context.viewModel.model.getOptions(),u=function(e,t,i,s){if(0===t.length)return 0;const n=e.createElement("div");n.style.position="absolute",n.style.top="-50000px",n.style.width="50000px";const r=e.createElement("span");(0,g.M)(r,i),r.style.whiteSpace="pre",r.style.tabSize=s*i.spaceWidth+"px",r.append(t),n.appendChild(r),e.body.appendChild(n);const o=r.offsetWidth;return n.remove(),o}(this.textArea.domNode.ownerDocument,h,this._fontInfo,d);return{distanceToModelLineStart:c,widthOfHiddenTextBefore:u}})(),{distanceToModelLineEnd:r}=(()=>{const e=t.value.substring(Math.max(t.selectionStart,t.selectionEnd)),s=e.indexOf("\n"),n=-1===s?e:e.substring(0,s),r=n.indexOf("\t"),o=-1===r?n.length:n.length-r-1,a=i.getEndPosition(),l=Math.min(this._context.viewModel.model.getLineMaxColumn(a.lineNumber)-a.column,o);return{distanceToModelLineEnd:this._context.viewModel.model.getLineMaxColumn(a.lineNumber)-a.column-l}})();this._context.viewModel.revealRange("keyboard",!0,q.Q.fromPositions(this._selections[0].getStartPosition()),0,1),this._visibleTextArea=new Ve(this._context,i.startLineNumber,s,n,r),this.textArea.setAttribute("wrap",this._textAreaWrapping&&!this._visibleTextArea?"on":"off"),this._visibleTextArea.prepareRender(this._visibleRangeProvider),this._render(),this.textArea.setClassName(`inputarea ${De} ime-input`),this._viewController.compositionStart(),this._context.viewModel.onCompositionStart()}))),this._register(this._textAreaInput.onCompositionUpdate((e=>{this._visibleTextArea&&(this._visibleTextArea.prepareRender(this._visibleRangeProvider),this._render())}))),this._register(this._textAreaInput.onCompositionEnd((()=>{this._visibleTextArea=null,this.textArea.setAttribute("wrap",this._textAreaWrapping&&!this._visibleTextArea?"on":"off"),this._render(),this.textArea.setClassName(`inputarea ${De}`),this._viewController.compositionEnd(),this._context.viewModel.onCompositionEnd()}))),this._register(this._textAreaInput.onFocus((()=>{this._context.viewModel.setHasFocus(!0)}))),this._register(this._textAreaInput.onBlur((()=>{this._context.viewModel.setHasFocus(!1)}))),this._register(Fe.M.onDidChange((()=>{this._ensureReadOnlyAttribute()})))}writeScreenReaderContent(e){this._textAreaInput.writeNativeTextAreaContent(e)}dispose(){super.dispose()}_getAndroidWordAtPosition(e){const t=this._context.viewModel.getLineContent(e.lineNumber),i=(0,Oe.i)('`~!@#$%^&*()-=+[{]}\\|;:",.<>/?',[]);let s=!0,n=e.column,r=!0,o=e.column,a=0;for(;a<50&&(s||r);){if(s&&n<=1&&(s=!1),s){const e=t.charCodeAt(n-2);0!==i.get(e)?s=!1:n--}if(r&&o>t.length&&(r=!1),r){const e=t.charCodeAt(o-1);0!==i.get(e)?r=!1:o++}a++}return[t.substring(n-1,o-1),e.column-n]}_getWordBeforePosition(e){const t=this._context.viewModel.getLineContent(e.lineNumber),i=(0,Oe.i)(this._context.configuration.options.get(132),[]);let s=e.column,n=0;for(;s>1;){const r=t.charCodeAt(s-2);if(0!==i.get(r)||n>50)return t.substring(s-1,e.column-1);n++,s--}return t.substring(0,e.column-1)}_getCharacterBeforePosition(e){if(e.column>1){const t=this._context.viewModel.getLineContent(e.lineNumber).charAt(e.column-2);if(!Re.pc(t.charCodeAt(0)))return t}return""}_getAriaLabel(e){if(1===e.get(2)){const e=this._keybindingService.lookupKeybinding("editor.action.toggleScreenReaderAccessibilityMode")?.getAriaLabel(),t=this._keybindingService.lookupKeybinding("workbench.action.showCommands")?.getAriaLabel(),i=this._keybindingService.lookupKeybinding("workbench.action.openGlobalKeybindings")?.getAriaLabel(),s=Le.kg("accessibilityModeOff","The editor is not accessible at this time.");return e?Le.kg("accessibilityOffAriaLabel","{0} To enable screen reader optimized mode, use {1}",s,e):t?Le.kg("accessibilityOffAriaLabelNoKb","{0} To enable screen reader optimized mode, open the quick pick with {1} and run the command Toggle Screen Reader Accessibility Mode, which is currently not triggerable via keyboard.",s,t):i?Le.kg("accessibilityOffAriaLabelNoKbs","{0} Please assign a keybinding for the command Toggle Screen Reader Accessibility Mode by accessing the keybindings editor with {1} and run it.",s,i):s}return e.get(4)}_setAccessibilityOptions(e){this._accessibilitySupport=e.get(2);const t=e.get(3);2===this._accessibilitySupport&&t===L.qB.accessibilityPageSize.defaultValue?this._accessibilityPageSize=500:this._accessibilityPageSize=t;const i=e.get(146).wrappingColumn;if(-1!==i&&1!==this._accessibilitySupport){const t=e.get(50);this._textAreaWrapping=!0,this._textAreaWidth=Math.round(i*t.typicalHalfwidthCharacterWidth)}else this._textAreaWrapping=!1,this._textAreaWidth=ze?0:1}onConfigurationChanged(e){const t=this._context.configuration.options,i=t.get(146);this._setAccessibilityOptions(t),this._contentLeft=i.contentLeft,this._contentWidth=i.contentWidth,this._contentHeight=i.height,this._fontInfo=t.get(50),this._lineHeight=t.get(67),this._emptySelectionClipboard=t.get(37),this._copyWithSyntaxHighlighting=t.get(25),this.textArea.setAttribute("wrap",this._textAreaWrapping&&!this._visibleTextArea?"on":"off");const{tabSize:s}=this._context.viewModel.model.getOptions();return this.textArea.domNode.style.tabSize=s*this._fontInfo.spaceWidth+"px",this.textArea.setAttribute("aria-label",this._getAriaLabel(t)),this.textArea.setAttribute("aria-required",t.get(5)?"true":"false"),this.textArea.setAttribute("tabindex",String(t.get(125))),(e.hasChanged(34)||e.hasChanged(92))&&this._ensureReadOnlyAttribute(),e.hasChanged(2)&&this._textAreaInput.writeNativeTextAreaContent("strategy changed"),!0}onCursorStateChanged(e){return this._selections=e.selections.slice(0),this._modelSelections=e.modelSelections.slice(0),this._textAreaInput.writeNativeTextAreaContent("selection changed"),!0}onDecorationsChanged(e){return!0}onFlushed(e){return!0}onLinesChanged(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return this._scrollLeft=e.scrollLeft,this._scrollTop=e.scrollTop,!0}onZonesChanged(e){return!0}isFocused(){return this._textAreaInput.isFocused()}focusTextArea(){this._textAreaInput.focusTextArea()}getLastRenderData(){return this._lastRenderPosition}setAriaOptions(e){e.activeDescendant?(this.textArea.setAttribute("aria-haspopup","true"),this.textArea.setAttribute("aria-autocomplete","list"),this.textArea.setAttribute("aria-activedescendant",e.activeDescendant)):(this.textArea.setAttribute("aria-haspopup","false"),this.textArea.setAttribute("aria-autocomplete","both"),this.textArea.removeAttribute("aria-activedescendant")),e.role&&this.textArea.setAttribute("role",e.role)}_ensureReadOnlyAttribute(){const e=this._context.configuration.options;!Fe.M.enabled||e.get(34)&&e.get(92)?this.textArea.setAttribute("readonly","true"):this.textArea.removeAttribute("readonly")}prepareRender(e){this._primaryCursorPosition=new Y.y(this._selections[0].positionLineNumber,this._selections[0].positionColumn),this._primaryCursorVisibleRange=e.visibleRangeForPosition(this._primaryCursorPosition),this._visibleTextArea?.prepareRender(e)}render(e){this._textAreaInput.writeNativeTextAreaContent("render"),this._render()}_render(){if(this._visibleTextArea){const e=this._visibleTextArea.visibleTextareaStart,t=this._visibleTextArea.visibleTextareaEnd,i=this._visibleTextArea.startPosition,s=this._visibleTextArea.endPosition;if(i&&s&&e&&t&&t.left>=this._scrollLeft&&e.left<=this._scrollLeft+this._contentWidth){const n=this._context.viewLayout.getVerticalOffsetForLineNumber(this._primaryCursorPosition.lineNumber)-this._scrollTop,r=this._newlinecount(this.textArea.domNode.value.substr(0,this.textArea.domNode.selectionStart));let o=this._visibleTextArea.widthOfHiddenLineTextBefore,a=this._contentLeft+e.left-this._scrollLeft,l=t.left-e.left+1;if(athis._contentWidth&&(l=this._contentWidth);const c=this._context.viewModel.getViewLineData(i.lineNumber),h=c.tokens.findTokenIndexAtOffset(i.column-1),d=h===c.tokens.findTokenIndexAtOffset(s.column-1),u=this._visibleTextArea.definePresentation(d?c.tokens.getPresentation(h):null);this.textArea.domNode.scrollTop=r*this._lineHeight,this.textArea.domNode.scrollLeft=o,this._doRender({lastRenderPosition:null,top:n,left:a,width:l,height:this._lineHeight,useCover:!1,color:(Me.dG.getColorMap()||[])[u.foreground],italic:u.italic,bold:u.bold,underline:u.underline,strikethrough:u.strikethrough})}return}if(!this._primaryCursorVisibleRange)return void this._renderAtTopLeft();const e=this._contentLeft+this._primaryCursorVisibleRange.left-this._scrollLeft;if(ethis._contentLeft+this._contentWidth)return void this._renderAtTopLeft();const t=this._context.viewLayout.getVerticalOffsetForLineNumber(this._selections[0].positionLineNumber)-this._scrollTop;if(t<0||t>this._contentHeight)this._renderAtTopLeft();else if(_.zx||2===this._accessibilitySupport){this._doRender({lastRenderPosition:this._primaryCursorPosition,top:t,left:this._textAreaWrapping?this._contentLeft:e,width:this._textAreaWidth,height:this._lineHeight,useCover:!1}),this.textArea.domNode.scrollLeft=this._primaryCursorVisibleRange.left;const i=this._textAreaInput.textAreaState.newlineCountBeforeSelection??this._newlinecount(this.textArea.domNode.value.substr(0,this.textArea.domNode.selectionStart));this.textArea.domNode.scrollTop=i*this._lineHeight}else this._doRender({lastRenderPosition:this._primaryCursorPosition,top:t,left:this._textAreaWrapping?this._contentLeft:e,width:this._textAreaWidth,height:ze?0:1,useCover:!1})}_newlinecount(e){let t=0,i=-1;for(;;){if(i=e.indexOf("\n",i+1),-1===i)break;t++}return t}_renderAtTopLeft(){this._doRender({lastRenderPosition:null,top:0,left:0,width:this._textAreaWidth,height:ze?0:1,useCover:!0})}_doRender(e){this._lastRenderPosition=e.lastRenderPosition;const t=this.textArea,i=this.textAreaCover;(0,g.M)(t,this._fontInfo),t.setTop(e.top),t.setLeft(e.left),t.setWidth(e.width),t.setHeight(e.height),t.setColor(e.color?Pe.Q1.Format.CSS.formatHex(e.color):""),t.setFontStyle(e.italic?"italic":""),e.bold&&t.setFontWeight("bold"),t.setTextDecoration(`${e.underline?" underline":""}${e.strikethrough?" line-through":""}`),i.setTop(e.useCover?e.top:0),i.setLeft(e.useCover?e.left:0),i.setWidth(e.useCover?e.width:0),i.setHeight(e.useCover?e.height:0);const s=this._context.configuration.options;s.get(57)?i.setClassName("monaco-editor-background textAreaCover "+Ie.OUTER_CLASS_NAME):0!==s.get(68).renderType?i.setClassName("monaco-editor-background textAreaCover "+Ne.CLASS_NAME):i.setClassName("monaco-editor-background textAreaCover")}};Ge=Be([We(3,Ue.b),We(4,He._Y)],Ge);var je=i(80624),Ke=i(36999);class Ye{constructor(e,t,i,s){this.configuration=e,this.viewModel=t,this.userInputEvents=i,this.commandDelegate=s}paste(e,t,i,s){this.commandDelegate.paste(e,t,i,s)}type(e){this.commandDelegate.type(e)}compositionType(e,t,i,s){this.commandDelegate.compositionType(e,t,i,s)}compositionStart(){this.commandDelegate.startComposition()}compositionEnd(){this.commandDelegate.endComposition()}cut(){this.commandDelegate.cut()}setSelection(e){Ke.QM.SetSelection.runCoreEditorCommand(this.viewModel,{source:"keyboard",selection:e})}_validateViewColumn(e){const t=this.viewModel.getLineMinColumn(e.lineNumber);return e.column=4?this._selectAll():3===e.mouseDownCount?this._hasMulticursorModifier(e)?e.inSelectionMode?this._lastCursorLineSelectDrag(e.position,e.revealType):this._lastCursorLineSelect(e.position,e.revealType):e.inSelectionMode?this._lineSelectDrag(e.position,e.revealType):this._lineSelect(e.position,e.revealType):2===e.mouseDownCount?e.onInjectedText||(this._hasMulticursorModifier(e)?this._lastCursorWordSelect(e.position,e.revealType):e.inSelectionMode?this._wordSelectDrag(e.position,e.revealType):this._wordSelect(e.position,e.revealType)):this._hasMulticursorModifier(e)?this._hasNonMulticursorModifier(e)||(e.shiftKey?this._columnSelect(e.position,e.mouseColumn,!0):e.inSelectionMode?this._lastCursorMoveToSelect(e.position,e.revealType):this._createCursor(e.position,!1)):e.inSelectionMode?e.altKey||s?this._columnSelect(e.position,e.mouseColumn,!0):this._moveToSelect(e.position,e.revealType):this.moveTo(e.position,e.revealType)}_usualArgs(e,t){return e=this._validateViewColumn(e),{source:"mouse",position:this._convertViewToModelPosition(e),viewPosition:e,revealType:t}}moveTo(e,t){Ke.QM.MoveTo.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_moveToSelect(e,t){Ke.QM.MoveToSelect.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_columnSelect(e,t,i){e=this._validateViewColumn(e),Ke.QM.ColumnSelect.runCoreEditorCommand(this.viewModel,{source:"mouse",position:this._convertViewToModelPosition(e),viewPosition:e,mouseColumn:t,doColumnSelect:i})}_createCursor(e,t){e=this._validateViewColumn(e),Ke.QM.CreateCursor.runCoreEditorCommand(this.viewModel,{source:"mouse",position:this._convertViewToModelPosition(e),viewPosition:e,wholeLine:t})}_lastCursorMoveToSelect(e,t){Ke.QM.LastCursorMoveToSelect.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_wordSelect(e,t){Ke.QM.WordSelect.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_wordSelectDrag(e,t){Ke.QM.WordSelectDrag.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_lastCursorWordSelect(e,t){Ke.QM.LastCursorWordSelect.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_lineSelect(e,t){Ke.QM.LineSelect.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_lineSelectDrag(e,t){Ke.QM.LineSelectDrag.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_lastCursorLineSelect(e,t){Ke.QM.LastCursorLineSelect.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_lastCursorLineSelectDrag(e,t){Ke.QM.LastCursorLineSelectDrag.runCoreEditorCommand(this.viewModel,this._usualArgs(e,t))}_selectAll(){Ke.QM.SelectAll.runCoreEditorCommand(this.viewModel,{source:"mouse"})}_convertViewToModelPosition(e){return this.viewModel.coordinatesConverter.convertViewPositionToModelPosition(e)}emitKeyDown(e){this.userInputEvents.emitKeyDown(e)}emitKeyUp(e){this.userInputEvents.emitKeyUp(e)}emitContextMenu(e){this.userInputEvents.emitContextMenu(e)}emitMouseMove(e){this.userInputEvents.emitMouseMove(e)}emitMouseLeave(e){this.userInputEvents.emitMouseLeave(e)}emitMouseUp(e){this.userInputEvents.emitMouseUp(e)}emitMouseDown(e){this.userInputEvents.emitMouseDown(e)}emitMouseDrag(e){this.userInputEvents.emitMouseDrag(e)}emitMouseDrop(e){this.userInputEvents.emitMouseDrop(e)}emitMouseDropCanceled(){this.userInputEvents.emitMouseDropCanceled()}emitMouseWheel(e){this.userInputEvents.emitMouseWheel(e)}}var qe=i(80789),$e=i(99020);class Qe{constructor(e){this._lineFactory=e,this._set(1,[])}flush(){this._set(1,[])}_set(e,t){this._lines=t,this._rendLineNumberStart=e}_get(){return{rendLineNumberStart:this._rendLineNumberStart,lines:this._lines}}getStartLineNumber(){return this._rendLineNumberStart}getEndLineNumber(){return this._rendLineNumberStart+this._lines.length-1}getCount(){return this._lines.length}getLine(e){const t=e-this._rendLineNumberStart;if(t<0||t>=this._lines.length)throw new c.D7("Illegal value for lineNumber");return this._lines[t]}onLinesDeleted(e,t){if(0===this.getCount())return null;const i=this.getStartLineNumber(),s=this.getEndLineNumber();if(ts)return null;let n=0,r=0;for(let o=i;o<=s;o++){const i=o-this._rendLineNumberStart;e<=o&&o<=t&&(0===r?(n=i,r=1):r++)}if(e=s&&o<=n&&(this._lines[o-this._rendLineNumberStart].onContentChanged(),r=!0);return r}onLinesInserted(e,t){if(0===this.getCount())return null;const i=t-e+1,s=this.getStartLineNumber(),n=this.getEndLineNumber();if(e<=s)return this._rendLineNumberStart+=i,null;if(e>n)return null;if(i+e>n){return this._lines.splice(e-this._rendLineNumberStart,n-e+1)}const r=[];for(let h=0;hi)continue;const o=Math.max(t,r.fromLineNumber),a=Math.min(i,r.toLineNumber);for(let e=o;e<=a;e++){const t=e-this._rendLineNumberStart;this._lines[t].onTokensChanged(),s=!0}}return s}}class Xe{constructor(e){this._lineFactory=e,this.domNode=this._createDomNode(),this._linesCollection=new Qe(this._lineFactory)}_createDomNode(){const e=(0,H.Z)(document.createElement("div"));return e.setClassName("view-layer"),e.setPosition("absolute"),e.domNode.setAttribute("role","presentation"),e.domNode.setAttribute("aria-hidden","true"),e}onConfigurationChanged(e){return!!e.hasChanged(146)}onFlushed(e){return this._linesCollection.flush(),!0}onLinesChanged(e){return this._linesCollection.onLinesChanged(e.fromLineNumber,e.count)}onLinesDeleted(e){const t=this._linesCollection.onLinesDeleted(e.fromLineNumber,e.toLineNumber);if(t)for(let i=0,s=t.length;ie})}constructor(e,t,i){this._domNode=e,this._lineFactory=t,this._viewportData=i}render(e,t,i,s){const n={rendLineNumberStart:e.rendLineNumberStart,lines:e.lines.slice(0),linesLength:e.linesLength};if(n.rendLineNumberStart+n.linesLength-1t){const e=t,r=Math.min(i,n.rendLineNumberStart-1);e<=r&&(this._insertLinesBefore(n,e,r,s,t),n.linesLength+=r-e+1)}else if(n.rendLineNumberStart0&&(this._removeLinesBefore(n,e),n.linesLength-=e)}if(n.rendLineNumberStart=t,n.rendLineNumberStart+n.linesLength-1i){const e=Math.max(0,i-n.rendLineNumberStart+1),t=n.linesLength-1-e+1;t>0&&(this._removeLinesAfter(n,t),n.linesLength-=t)}return this._finishRendering(n,!1,s),n}_renderUntouchedLines(e,t,i,s,n){const r=e.rendLineNumberStart,o=e.lines;for(let a=t;a<=i;a++){const e=r+a;o[a].layoutLine(e,s[e-n],this._viewportData.lineHeight)}}_insertLinesBefore(e,t,i,s,n){const r=[];let o=0;for(let a=t;a<=i;a++)r[o++]=this._lineFactory.createLine();e.lines=r.concat(e.lines)}_removeLinesBefore(e,t){for(let i=0;i=0;o--){const t=e.lines[o];s[o]&&(t.setDomNode(r),r=r.previousSibling)}}_finishRenderingInvalidLines(e,t,i){const s=document.createElement("div");Ze._ttPolicy&&(t=Ze._ttPolicy.createHTML(t)),s.innerHTML=t;for(let n=0;nnew et(this._dynamicOverlays)}),this.domNode=this._visibleLines.domNode;const t=this._context.configuration.options.get(50);(0,g.M)(this.domNode,t),this.domNode.setClassName("view-overlays")}shouldRender(){if(super.shouldRender())return!0;for(let e=0,t=this._dynamicOverlays.length;ee.shouldRender()));for(let i=0,s=t.length;i'),n.appendString(r),n.appendString(""),!0)}layoutLine(e,t,i){this._domNode&&(this._domNode.setTop(t),this._domNode.setHeight(i))}}class tt extends Je{constructor(e){super(e);const t=this._context.configuration.options.get(146);this._contentWidth=t.contentWidth,this.domNode.setHeight(0)}onConfigurationChanged(e){const t=this._context.configuration.options.get(146);return this._contentWidth=t.contentWidth,super.onConfigurationChanged(e)||!0}onScrollChanged(e){return super.onScrollChanged(e)||e.scrollWidthChanged}_viewOverlaysRender(e){super._viewOverlaysRender(e),this.domNode.setWidth(Math.max(e.scrollWidth,this._contentWidth))}}class it extends Je{constructor(e){super(e);const t=this._context.configuration.options,i=t.get(146);this._contentLeft=i.contentLeft,this.domNode.setClassName("margin-view-overlays"),this.domNode.setWidth(1),(0,g.M)(this.domNode,t.get(50))}onConfigurationChanged(e){const t=this._context.configuration.options;(0,g.M)(this.domNode,t.get(50));const i=t.get(146);return this._contentLeft=i.contentLeft,super.onConfigurationChanged(e)||!0}onScrollChanged(e){return super.onScrollChanged(e)||e.scrollHeightChanged}_viewOverlaysRender(e){super._viewOverlaysRender(e);const t=Math.min(e.scrollHeight,1e6);this.domNode.setHeight(t),this.domNode.setWidth(this._contentLeft)}}class st{constructor(e){this.onKeyDown=null,this.onKeyUp=null,this.onContextMenu=null,this.onMouseMove=null,this.onMouseLeave=null,this.onMouseDown=null,this.onMouseUp=null,this.onMouseDrag=null,this.onMouseDrop=null,this.onMouseDropCanceled=null,this.onMouseWheel=null,this._coordinatesConverter=e}emitKeyDown(e){this.onKeyDown?.(e)}emitKeyUp(e){this.onKeyUp?.(e)}emitContextMenu(e){this.onContextMenu?.(this._convertViewToModelMouseEvent(e))}emitMouseMove(e){this.onMouseMove?.(this._convertViewToModelMouseEvent(e))}emitMouseLeave(e){this.onMouseLeave?.(this._convertViewToModelMouseEvent(e))}emitMouseDown(e){this.onMouseDown?.(this._convertViewToModelMouseEvent(e))}emitMouseUp(e){this.onMouseUp?.(this._convertViewToModelMouseEvent(e))}emitMouseDrag(e){this.onMouseDrag?.(this._convertViewToModelMouseEvent(e))}emitMouseDrop(e){this.onMouseDrop?.(this._convertViewToModelMouseEvent(e))}emitMouseDropCanceled(){this.onMouseDropCanceled?.()}emitMouseWheel(e){this.onMouseWheel?.(e)}_convertViewToModelMouseEvent(e){return e.target?{event:e.event,target:this._convertViewToModelMouseTarget(e.target)}:e}_convertViewToModelMouseTarget(e){return st.convertViewToModelMouseTarget(e,this._coordinatesConverter)}static convertViewToModelMouseTarget(e,t){const i={...e};return i.position&&(i.position=t.convertViewPositionToModelPosition(i.position)),i.range&&(i.range=t.convertViewRangeToModelRange(i.range)),5!==i.type&&8!==i.type||(i.detail=this.convertViewToModelViewZoneData(i.detail,t)),i}static convertViewToModelViewZoneData(e,t){return{viewZoneId:e.viewZoneId,positionBefore:e.positionBefore?t.convertViewPositionToModelPosition(e.positionBefore):e.positionBefore,positionAfter:e.positionAfter?t.convertViewPositionToModelPosition(e.positionAfter):e.positionAfter,position:t.convertViewPositionToModelPosition(e.position),afterLineNumber:t.convertViewPositionToModelPosition(new Y.y(e.afterLineNumber,1)).lineNumber}}}class nt extends z{constructor(e){super(e),this.blocks=[],this.contentWidth=-1,this.contentLeft=0,this.domNode=(0,H.Z)(document.createElement("div")),this.domNode.setAttribute("role","presentation"),this.domNode.setAttribute("aria-hidden","true"),this.domNode.setClassName("blockDecorations-container"),this.update()}update(){let e=!1;const t=this._context.configuration.options.get(146),i=t.contentWidth-t.verticalScrollbarWidth;this.contentWidth!==i&&(this.contentWidth=i,e=!0);const s=t.contentLeft;return this.contentLeft!==s&&(this.contentLeft=s,e=!0),e}dispose(){super.dispose()}onConfigurationChanged(e){return this.update()}onScrollChanged(e){return e.scrollTopChanged||e.scrollLeftChanged}onDecorationsChanged(e){return!0}onZonesChanged(e){return!0}prepareRender(e){}render(e){let t=0;const i=e.getDecorationsInViewport();for(const s of i){if(!s.options.blockClassName)continue;let i,n,r=this.blocks[t];r||(r=this.blocks[t]=(0,H.Z)(document.createElement("div")),this.domNode.appendChild(r)),s.options.blockIsAfterEnd?(i=e.getVerticalOffsetAfterLineNumber(s.range.endLineNumber,!1),n=e.getVerticalOffsetAfterLineNumber(s.range.endLineNumber,!0)):(i=e.getVerticalOffsetForLineNumber(s.range.startLineNumber,!0),n=s.range.isEmpty()&&!s.options.blockDoesNotCollapse?e.getVerticalOffsetForLineNumber(s.range.startLineNumber,!1):e.getVerticalOffsetAfterLineNumber(s.range.endLineNumber,!0));const[o,a,l,c]=s.options.blockPadding??[0,0,0,0];r.setClassName("blockDecorations-block "+s.options.blockClassName),r.setLeft(this.contentLeft-c),r.setWidth(this.contentWidth+c+a),r.setTop(i-e.scrollTop-o),r.setHeight(n-i+o+l),t++}for(let s=t;s0?this.domNode.setDisplay("block"):this.domNode.setDisplay("none"),this._cachedDomNodeOffsetWidth=-1,this._cachedDomNodeOffsetHeight=-1}_layoutBoxInViewport(e,t,i,s){const n=e.top,r=n,o=e.top+e.height,a=n-i,l=r>=i,c=o,h=s.viewportHeight-o>=i;let d=e.left;return d+t>s.scrollLeft+s.viewportWidth&&(d=s.scrollLeft+s.viewportWidth-t),dr){const e=a-(r-s);a-=e,i-=e}if(a=22,f=d+i<=u.height-22;return this._fixedOverflowWidgets?{fitsAbove:m,aboveTop:Math.max(h,22),fitsBelow:f,belowTop:d,left:p}:{fitsAbove:m,aboveTop:n,fitsBelow:f,belowTop:r,left:g}}_prepareRenderWidgetAtExactPositionOverflowing(e){return new lt(e.top,e.left+this._contentLeft)}_getAnchorsCoordinates(e){return{primary:t(this._primaryAnchor.viewPosition,this._affinity,this._lineHeight),secondary:t(this._secondaryAnchor.viewPosition?.lineNumber===this._primaryAnchor.viewPosition?.lineNumber?this._secondaryAnchor.viewPosition:null,this._affinity,this._lineHeight)};function t(t,i,s){if(!t)return null;const n=e.visibleRangeForPosition(t);if(!n)return null;const r=1===t.column&&3===i?0:n.left,o=e.getVerticalOffsetForLineNumber(t.lineNumber)-e.scrollTop;return new ct(o,r,s)}}_reduceAnchorCoordinates(e,t,i){if(!t)return e;const s=this._context.configuration.options.get(50);let n=t.left;return n=ne.endLineNumber||this.domNode.setMaxWidth(this._maxWidth))}prepareRender(e){this._renderData=this._prepareRenderWidget(e)}render(e){if(!this._renderData||"offViewport"===this._renderData.kind)return this._isVisible&&(this.domNode.removeAttribute("monaco-visible-content-widget"),this._isVisible=!1,"offViewport"===this._renderData?.kind&&this._renderData.preserveFocus?this.domNode.setTop(-1e3):this.domNode.setVisibility("hidden")),void("function"===typeof this._actual.afterRender&&ht(this._actual.afterRender,this._actual,null));this.allowEditorOverflow?(this.domNode.setTop(this._renderData.coordinate.top),this.domNode.setLeft(this._renderData.coordinate.left)):(this.domNode.setTop(this._renderData.coordinate.top+e.scrollTop-e.bigNumbersDelta),this.domNode.setLeft(this._renderData.coordinate.left)),this._isVisible||(this.domNode.setVisibility("inherit"),this.domNode.setAttribute("monaco-visible-content-widget","true"),this._isVisible=!0),"function"===typeof this._actual.afterRender&&ht(this._actual.afterRender,this._actual,this._renderData.position)}}class at{constructor(e,t){this.modelPosition=e,this.viewPosition=t}}class lt{constructor(e,t){this.top=e,this.left=t,this._coordinateBrand=void 0}}class ct{constructor(e,t,i){this.top=e,this.left=t,this.height=i,this._anchorCoordinateBrand=void 0}}function ht(e,t,...i){try{return e.call(t,...i)}catch{return null}}var dt=i(86723);class ut extends xe{constructor(e){super(),this._context=e;const t=this._context.configuration.options,i=t.get(146);this._renderLineHighlight=t.get(97),this._renderLineHighlightOnlyWhenFocus=t.get(98),this._wordWrap=i.isViewportWrapping,this._contentLeft=i.contentLeft,this._contentWidth=i.contentWidth,this._selectionIsEmpty=!0,this._focused=!1,this._cursorLineNumbers=[1],this._selections=[new pe.L(1,1,1,1)],this._renderData=null,this._context.addEventHandler(this)}dispose(){this._context.removeEventHandler(this),super.dispose()}_readFromSelections(){let e=!1;const t=new Set;for(const n of this._selections)t.add(n.positionLineNumber);const i=Array.from(t);i.sort(((e,t)=>e-t)),m.aI(this._cursorLineNumbers,i)||(this._cursorLineNumbers=i,e=!0);const s=this._selections.every((e=>e.isEmpty()));return this._selectionIsEmpty!==s&&(this._selectionIsEmpty=s,e=!0),e}onThemeChanged(e){return this._readFromSelections()}onConfigurationChanged(e){const t=this._context.configuration.options,i=t.get(146);return this._renderLineHighlight=t.get(97),this._renderLineHighlightOnlyWhenFocus=t.get(98),this._wordWrap=i.isViewportWrapping,this._contentLeft=i.contentLeft,this._contentWidth=i.contentWidth,!0}onCursorStateChanged(e){return this._selections=e.selections,this._readFromSelections()}onFlushed(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return e.scrollWidthChanged||e.scrollTopChanged}onZonesChanged(e){return!0}onFocusChanged(e){return!!this._renderLineHighlightOnlyWhenFocus&&(this._focused=e.isFocused,!0)}prepareRender(e){if(!this._shouldRenderThis())return void(this._renderData=null);const t=e.visibleRange.startLineNumber,i=e.visibleRange.endLineNumber,s=[];for(let r=t;r<=i;r++){s[r-t]=""}if(this._wordWrap){const n=this._renderOne(e,!1);for(const e of this._cursorLineNumbers){const r=this._context.viewModel.coordinatesConverter,o=r.convertViewPositionToModelPosition(new Y.y(e,1)).lineNumber,a=r.convertModelPositionToViewPosition(new Y.y(o,1)).lineNumber,l=r.convertModelPositionToViewPosition(new Y.y(o,this._context.viewModel.model.getLineMaxColumn(o))).lineNumber,c=Math.max(a,t),h=Math.min(l,i);for(let e=c;e<=h;e++){s[e-t]=n}}}const n=this._renderOne(e,!0);for(const r of this._cursorLineNumbers){if(ri)continue;s[r-t]=n}this._renderData=s}render(e,t){if(!this._renderData)return"";const i=t-e;return i>=this._renderData.length?"":this._renderData[i]}_shouldRenderInMargin(){return("gutter"===this._renderLineHighlight||"all"===this._renderLineHighlight)&&(!this._renderLineHighlightOnlyWhenFocus||this._focused)}_shouldRenderInContent(){return("line"===this._renderLineHighlight||"all"===this._renderLineHighlight)&&this._selectionIsEmpty&&(!this._renderLineHighlightOnlyWhenFocus||this._focused)}}class gt extends ut{_renderOne(e,t){return`
    `}_shouldRenderThis(){return this._shouldRenderInContent()}_shouldRenderOther(){return this._shouldRenderInMargin()}}class pt extends ut{_renderOne(e,t){return`
    `}_shouldRenderThis(){return!0}_shouldRenderOther(){return this._shouldRenderInContent()}}(0,ke.zy)(((e,t)=>{const i=e.getColor(Ae.kG);if(i&&(t.addRule(`.monaco-editor .view-overlays .current-line { background-color: ${i}; }`),t.addRule(`.monaco-editor .margin-view-overlays .current-line-margin { background-color: ${i}; border: none; }`)),!i||i.isTransparent()||e.defines(Ae.Mf)){const i=e.getColor(Ae.Mf);i&&(t.addRule(`.monaco-editor .view-overlays .current-line-exact { border: 2px solid ${i}; }`),t.addRule(`.monaco-editor .margin-view-overlays .current-line-exact-margin { border: 2px solid ${i}; }`),(0,dt.Bb)(e.type)&&(t.addRule(".monaco-editor .view-overlays .current-line-exact { border-width: 1px; }"),t.addRule(".monaco-editor .margin-view-overlays .current-line-exact-margin { border-width: 1px; }")))}}));class mt extends xe{constructor(e){super(),this._context=e;const t=this._context.configuration.options;this._typicalHalfwidthCharacterWidth=t.get(50).typicalHalfwidthCharacterWidth,this._renderResult=null,this._context.addEventHandler(this)}dispose(){this._context.removeEventHandler(this),this._renderResult=null,super.dispose()}onConfigurationChanged(e){const t=this._context.configuration.options;return this._typicalHalfwidthCharacterWidth=t.get(50).typicalHalfwidthCharacterWidth,!0}onDecorationsChanged(e){return!0}onFlushed(e){return!0}onLinesChanged(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return e.scrollTopChanged||e.scrollWidthChanged}onZonesChanged(e){return!0}prepareRender(e){const t=e.getDecorationsInViewport();let i=[],s=0;for(let a=0,l=t.length;a{if(e.options.zIndext.options.zIndex)return 1;const i=e.options.className,s=t.options.className;return is?1:q.Q.compareRangesUsingStarts(e.range,t.range)}));const n=e.visibleRange.startLineNumber,r=e.visibleRange.endLineNumber,o=[];for(let a=n;a<=r;a++){o[a-n]=""}this._renderWholeLineDecorations(e,i,o),this._renderNormalDecorations(e,i,o),this._renderResult=o}_renderWholeLineDecorations(e,t,i){const s=e.visibleRange.startLineNumber,n=e.visibleRange.endLineNumber;for(let r=0,o=t.length;r',a=Math.max(e.range.startLineNumber,s),l=Math.min(e.range.endLineNumber,n);for(let t=a;t<=l;t++){i[t-s]+=o}}}_renderNormalDecorations(e,t,i){const s=e.visibleRange.startLineNumber;let n=null,r=!1,o=null,a=!1;for(let l=0,c=t.length;l';o[t]+=c}}}render(e,t){if(!this._renderResult)return"";const i=t-e;return i<0||i>=this._renderResult.length?"":this._renderResult[i]}}class ft extends z{constructor(e,t,i,s){super(e);const n=this._context.configuration.options,r=n.get(104),o=n.get(75),a=n.get(40),c=n.get(107),h={listenOnDomNode:i.domNode,className:"editor-scrollable "+(0,ke.Pz)(e.theme.type),useShadows:!1,lazyRender:!0,vertical:r.vertical,horizontal:r.horizontal,verticalHasArrows:r.verticalHasArrows,horizontalHasArrows:r.horizontalHasArrows,verticalScrollbarSize:r.verticalScrollbarSize,verticalSliderSize:r.verticalSliderSize,horizontalScrollbarSize:r.horizontalScrollbarSize,horizontalSliderSize:r.horizontalSliderSize,handleMouseWheel:r.handleMouseWheel,alwaysConsumeMouseWheel:r.alwaysConsumeMouseWheel,arrowSize:r.arrowSize,mouseWheelScrollSensitivity:o,fastScrollSensitivity:a,scrollPredominantAxis:c,scrollByPage:r.scrollByPage};this.scrollbar=this._register(new me.oO(t.domNode,h,this._context.viewLayout.getScrollable())),G.write(this.scrollbar.getDomNode(),6),this.scrollbarDomNode=(0,H.Z)(this.scrollbar.getDomNode()),this.scrollbarDomNode.setPosition("absolute"),this._setLayout();const d=(e,t,i)=>{const s={};if(t){const t=e.scrollTop;t&&(s.scrollTop=this._context.viewLayout.getCurrentScrollTop()+t,e.scrollTop=0)}if(i){const t=e.scrollLeft;t&&(s.scrollLeft=this._context.viewLayout.getCurrentScrollLeft()+t,e.scrollLeft=0)}this._context.viewModel.viewLayout.setScrollPosition(s,1)};this._register(l.ko(i.domNode,"scroll",(e=>d(i.domNode,!0,!0)))),this._register(l.ko(t.domNode,"scroll",(e=>d(t.domNode,!0,!1)))),this._register(l.ko(s.domNode,"scroll",(e=>d(s.domNode,!0,!1)))),this._register(l.ko(this.scrollbarDomNode.domNode,"scroll",(e=>d(this.scrollbarDomNode.domNode,!0,!1))))}dispose(){super.dispose()}_setLayout(){const e=this._context.configuration.options,t=e.get(146);this.scrollbarDomNode.setLeft(t.contentLeft);"right"===e.get(73).side?this.scrollbarDomNode.setWidth(t.contentWidth+t.minimap.minimapWidth):this.scrollbarDomNode.setWidth(t.contentWidth),this.scrollbarDomNode.setHeight(t.height)}getOverviewRulerLayoutInfo(){return this.scrollbar.getOverviewRulerLayoutInfo()}getDomNode(){return this.scrollbarDomNode}delegateVerticalScrollbarPointerDown(e){this.scrollbar.delegateVerticalScrollbarPointerDown(e)}delegateScrollFromMouseWheelEvent(e){this.scrollbar.delegateScrollFromMouseWheelEvent(e)}onConfigurationChanged(e){if(e.hasChanged(104)||e.hasChanged(75)||e.hasChanged(40)){const e=this._context.configuration.options,t=e.get(104),i=e.get(75),s=e.get(40),n=e.get(107),r={vertical:t.vertical,horizontal:t.horizontal,verticalScrollbarSize:t.verticalScrollbarSize,horizontalScrollbarSize:t.horizontalScrollbarSize,scrollByPage:t.scrollByPage,handleMouseWheel:t.handleMouseWheel,mouseWheelScrollSensitivity:i,fastScrollSensitivity:s,scrollPredominantAxis:n};this.scrollbar.updateOptions(r)}return e.hasChanged(146)&&this._setLayout(),!0}onScrollChanged(e){return!0}onThemeChanged(e){return this.scrollbar.updateClassName("editor-scrollable "+(0,ke.Pz)(this._context.theme.type)),!0}prepareRender(e){}render(e){this.scrollbar.renderNow()}}var _t=i(16223);class vt{constructor(e,t,i,s,n){this.startLineNumber=e,this.endLineNumber=t,this.className=i,this.tooltip=s,this._decorationToRenderBrand=void 0,this.zIndex=n??0}}class Ct{constructor(e,t,i){this.className=e,this.zIndex=t,this.tooltip=i}}class bt{constructor(){this.decorations=[]}add(e){this.decorations.push(e)}getDecorations(){return this.decorations}}class Et extends xe{_render(e,t,i){const s=[];for(let o=e;o<=t;o++){s[o-e]=new bt}if(0===i.length)return s;i.sort(((e,t)=>e.className===t.className?e.startLineNumber===t.startLineNumber?e.endLineNumber-t.endLineNumber:e.startLineNumber-t.startLineNumber:e.classNames)continue;const a=Math.max(r,i),l=this._context.viewModel.coordinatesConverter.convertViewPositionToModelPosition(new Y.y(a,0)),c=this._context.viewModel.glyphLanes.getLanesAtLine(l.lineNumber).indexOf(n.preference.lane);t.push(new wt(a,c,n.preference.zIndex,n))}}_collectSortedGlyphRenderRequests(e){const t=[];return this._collectDecorationBasedGlyphRenderRequest(e,t),this._collectWidgetBasedGlyphRenderRequest(e,t),t.sort(((e,t)=>e.lineNumber===t.lineNumber?e.laneIndex===t.laneIndex?e.zIndex===t.zIndex?t.type===e.type?0===e.type&&0===t.type?e.className0;){const e=t.peek();if(!e)break;const s=t.takeWhile((t=>t.lineNumber===e.lineNumber&&t.laneIndex===e.laneIndex));if(!s||0===s.length)break;const n=s[0];if(0===n.type){const e=[];for(const t of s){if(t.zIndex!==n.zIndex||t.type!==n.type)break;0!==e.length&&e[e.length-1]===t.className||e.push(t.className)}i.push(n.accept(e.join(" ")))}else n.widget.renderInfo={lineNumber:n.lineNumber,laneIndex:n.laneIndex}}this._decorationGlyphsToRender=i}render(e){if(!this._glyphMargin){for(const e of Object.values(this._widgets))e.domNode.setDisplay("none");for(;this._managedDomNodes.length>0;){const e=this._managedDomNodes.pop();e?.domNode.remove()}return}const t=Math.round(this._glyphMarginWidth/this._glyphMarginDecorationLaneCount);for(const i of Object.values(this._widgets))if(i.renderInfo){const s=e.viewportData.relativeVerticalOffset[i.renderInfo.lineNumber-e.viewportData.startLineNumber],n=this._glyphMarginLeft+i.renderInfo.laneIndex*this._lineHeight;i.domNode.setDisplay("block"),i.domNode.setTop(s),i.domNode.setLeft(n),i.domNode.setWidth(t),i.domNode.setHeight(this._lineHeight)}else i.domNode.setDisplay("none");for(let i=0;ithis._decorationGlyphsToRender.length;){const e=this._managedDomNodes.pop();e?.domNode.remove()}}}class yt{constructor(e,t,i,s){this.lineNumber=e,this.laneIndex=t,this.zIndex=i,this.className=s,this.type=0}accept(e){return new Lt(this.lineNumber,this.laneIndex,e)}}class wt{constructor(e,t,i,s){this.lineNumber=e,this.laneIndex=t,this.zIndex=i,this.widget=s,this.type=1}}class Lt{constructor(e,t,i){this.lineNumber=e,this.laneIndex=t,this.combinedClassName=i}}var Rt=i(631),Tt=i(53450),xt=i(84739);class kt extends xe{constructor(e){super(),this._context=e,this._primaryPosition=null;const t=this._context.configuration.options,i=t.get(147),s=t.get(50);this._spaceWidth=s.spaceWidth,this._maxIndentLeft=-1===i.wrappingColumn?-1:i.wrappingColumn*s.typicalHalfwidthCharacterWidth,this._bracketPairGuideOptions=t.get(16),this._renderResult=null,this._context.addEventHandler(this)}dispose(){this._context.removeEventHandler(this),this._renderResult=null,super.dispose()}onConfigurationChanged(e){const t=this._context.configuration.options,i=t.get(147),s=t.get(50);return this._spaceWidth=s.spaceWidth,this._maxIndentLeft=-1===i.wrappingColumn?-1:i.wrappingColumn*s.typicalHalfwidthCharacterWidth,this._bracketPairGuideOptions=t.get(16),!0}onCursorStateChanged(e){const t=e.selections[0].getPosition();return!this._primaryPosition?.equals(t)&&(this._primaryPosition=t,!0)}onDecorationsChanged(e){return!0}onFlushed(e){return!0}onLinesChanged(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return e.scrollTopChanged}onZonesChanged(e){return!0}onLanguageConfigurationChanged(e){return!0}prepareRender(e){if(!this._bracketPairGuideOptions.indentation&&!1===this._bracketPairGuideOptions.bracketPairs)return void(this._renderResult=null);const t=e.visibleRange.startLineNumber,i=e.visibleRange.endLineNumber,s=e.scrollWidth,n=this._primaryPosition,r=this.getGuidesByLine(t,Math.min(i+1,this._context.viewModel.getLineCount()),n),o=[];for(let a=t;a<=i;a++){const i=a-t,n=r[i];let l="";const c=e.visibleRangeForPosition(new Y.y(a,1))?.left??0;for(const t of n){const i=-1===t.column?c+(t.visibleColumn-1)*this._spaceWidth:e.visibleRangeForPosition(new Y.y(a,t.column)).left;if(i>s||this._maxIndentLeft>0&&i>this._maxIndentLeft)break;const n=t.horizontalLine?t.horizontalLine.top?"horizontal-top":"horizontal-bottom":"vertical",r=t.horizontalLine?(e.visibleRangeForPosition(new Y.y(a,t.horizontalLine.endColumn))?.left??i+this._spaceWidth)-i:this._spaceWidth;l+=`
    `}o[i]=l}this._renderResult=o}getGuidesByLine(e,t,i){const s=!1!==this._bracketPairGuideOptions.bracketPairs?this._context.viewModel.getBracketGuidesInRangeByLine(e,t,i,{highlightActive:this._bracketPairGuideOptions.highlightActiveBracketPair,horizontalGuides:!0===this._bracketPairGuideOptions.bracketPairsHorizontal?xt.N6.Enabled:"active"===this._bracketPairGuideOptions.bracketPairsHorizontal?xt.N6.EnabledForActive:xt.N6.Disabled,includeInactive:!0===this._bracketPairGuideOptions.bracketPairs}):null,n=this._bracketPairGuideOptions.indentation?this._context.viewModel.getLinesIndentGuides(e,t):null;let r=0,o=0,a=0;if(!1!==this._bracketPairGuideOptions.highlightActiveIndentation&&i){const s=this._context.viewModel.getActiveIndentGuide(i.lineNumber,e,t);r=s.startLineNumber,o=s.endLineNumber,a=s.indent}const{indentSize:l}=this._context.viewModel.model.getOptions(),c=[];for(let h=e;h<=t;h++){const t=new Array;c.push(t);const i=s?s[h-e]:[],d=new m.j3(i),u=n?n[h-e]:0;for(let e=1;e<=u;e++){const s=(e-1)*l+1,n=("always"===this._bracketPairGuideOptions.highlightActiveIndentation||0===i.length)&&r<=h&&h<=o&&e===a;t.push(...d.takeWhile((e=>e.visibleColumn!0))||[])}return c}render(e,t){if(!this._renderResult)return"";const i=t-e;return i<0||i>=this._renderResult.length?"":this._renderResult[i]}}function At(e){if(!e||!e.isTransparent())return e}(0,ke.zy)(((e,t)=>{const i=[{bracketColor:Ae.sN,guideColor:Ae.n4,guideColorActive:Ae.bB},{bracketColor:Ae.lQ,guideColor:Ae.I2,guideColorActive:Ae.WS},{bracketColor:Ae.ss,guideColor:Ae.Bo,guideColorActive:Ae.Pe},{bracketColor:Ae.l5,guideColor:Ae.If,guideColorActive:Ae.WD},{bracketColor:Ae.sH,guideColor:Ae.BD,guideColorActive:Ae.P1},{bracketColor:Ae.zp,guideColor:Ae.IW,guideColorActive:Ae.WY}],s=new Tt.k,n=[{indentColor:Ae.vV,indentColorActive:Ae.H0},{indentColor:Ae.ob,indentColorActive:Ae.Am},{indentColor:Ae.hz,indentColorActive:Ae.tK},{indentColor:Ae.ow,indentColorActive:Ae.A3},{indentColor:Ae.vP,indentColorActive:Ae.tp},{indentColor:Ae.CM,indentColorActive:Ae.As}],r=i.map((t=>{const i=e.getColor(t.bracketColor),s=e.getColor(t.guideColor),n=e.getColor(t.guideColorActive),r=At(At(s)??i?.transparent(.3)),o=At(At(n)??i);if(r&&o)return{guideColor:r,guideColorActive:o}})).filter(Rt.O9),o=n.map((t=>{const i=e.getColor(t.indentColor),s=e.getColor(t.indentColorActive),n=At(i),r=At(s);if(n&&r)return{indentColor:n,indentColorActive:r}})).filter(Rt.O9);if(r.length>0){for(let e=0;e<30;e++){const i=r[e%r.length];t.addRule(`.monaco-editor .${s.getInlineClassNameOfLevel(e).replace(/ /g,".")} { --guide-color: ${i.guideColor}; --guide-color-active: ${i.guideColorActive}; }`)}t.addRule(".monaco-editor .vertical { box-shadow: 1px 0 0 0 var(--guide-color) inset; }"),t.addRule(".monaco-editor .horizontal-top { border-top: 1px solid var(--guide-color); }"),t.addRule(".monaco-editor .horizontal-bottom { border-bottom: 1px solid var(--guide-color); }"),t.addRule(`.monaco-editor .vertical.${s.activeClassName} { box-shadow: 1px 0 0 0 var(--guide-color-active) inset; }`),t.addRule(`.monaco-editor .horizontal-top.${s.activeClassName} { border-top: 1px solid var(--guide-color-active); }`),t.addRule(`.monaco-editor .horizontal-bottom.${s.activeClassName} { border-bottom: 1px solid var(--guide-color-active); }`)}if(o.length>0){for(let e=0;e<30;e++){const i=o[e%o.length];t.addRule(`.monaco-editor .lines-content .core-guide-indent.lvl-${e} { --indent-color: ${i.indentColor}; --indent-color-active: ${i.indentColorActive}; }`)}t.addRule(".monaco-editor .lines-content .core-guide-indent { box-shadow: 1px 0 0 0 var(--indent-color) inset; }"),t.addRule(".monaco-editor .lines-content .core-guide-indent.indent-active { box-shadow: 1px 0 0 0 var(--indent-color-active) inset; }")}}));var Nt=i(90766);class It{get didDomLayout(){return this._didDomLayout}readClientRect(){if(!this._clientRectRead){this._clientRectRead=!0;const e=this._domNode.getBoundingClientRect();this.markDidDomLayout(),this._clientRectDeltaLeft=e.left,this._clientRectScale=e.width/this._domNode.offsetWidth}}get clientRectDeltaLeft(){return this._clientRectRead||this.readClientRect(),this._clientRectDeltaLeft}get clientRectScale(){return this._clientRectRead||this.readClientRect(),this._clientRectScale}constructor(e,t){this._domNode=e,this.endNode=t,this._didDomLayout=!1,this._clientRectDeltaLeft=0,this._clientRectScale=1,this._clientRectRead=!1}markDidDomLayout(){this._didDomLayout=!0}}class Ot{constructor(){this._currentVisibleRange=new q.Q(1,1,1,1)}getCurrentVisibleRange(){return this._currentVisibleRange}setCurrentVisibleRange(e){this._currentVisibleRange=e}}class Dt{constructor(e,t,i,s,n,r,o){this.minimalReveal=e,this.lineNumber=t,this.startColumn=i,this.endColumn=s,this.startScrollTop=n,this.stopScrollTop=r,this.scrollType=o,this.type="range",this.minLineNumber=t,this.maxLineNumber=t}}class Mt{constructor(e,t,i,s,n){this.minimalReveal=e,this.selections=t,this.startScrollTop=i,this.stopScrollTop=s,this.scrollType=n,this.type="selections";let r=t[0].startLineNumber,o=t[0].endLineNumber;for(let a=1,l=t.length;anew K.Gb(this._viewLineOptions)}),this.domNode=this._visibleLines.domNode,G.write(this.domNode,8),this.domNode.setClassName(`view-lines ${De}`),(0,g.M)(this.domNode,n),this._maxLineWidth=0,this._asyncUpdateLineWidths=new Nt.uC((()=>{this._updateLineWidthsSlow()}),200),this._asyncCheckMonospaceFontAssumptions=new Nt.uC((()=>{this._checkMonospaceFontAssumptions()}),2e3),this._lastRenderedData=new Ot,this._horizontalRevealRequest=null,this._stickyScrollEnabled=s.get(116).enabled,this._maxNumberStickyLines=s.get(116).maxLineCount}dispose(){this._asyncUpdateLineWidths.dispose(),this._asyncCheckMonospaceFontAssumptions.dispose(),super.dispose()}getDomNode(){return this.domNode}onConfigurationChanged(e){this._visibleLines.onConfigurationChanged(e),e.hasChanged(147)&&(this._maxLineWidth=0);const t=this._context.configuration.options,i=t.get(50),s=t.get(147);return this._lineHeight=t.get(67),this._typicalHalfwidthCharacterWidth=i.typicalHalfwidthCharacterWidth,this._isViewportWrapping=s.isViewportWrapping,this._revealHorizontalRightPadding=t.get(101),this._cursorSurroundingLines=t.get(29),this._cursorSurroundingLinesStyle=t.get(30),this._canUseLayerHinting=!t.get(32),this._stickyScrollEnabled=t.get(116).enabled,this._maxNumberStickyLines=t.get(116).maxLineCount,(0,g.M)(this.domNode,i),this._onOptionsMaybeChanged(),e.hasChanged(146)&&(this._maxLineWidth=0),!0}_onOptionsMaybeChanged(){const e=this._context.configuration,t=new K.Ax(e,this._context.theme.type);if(!this._viewLineOptions.equals(t)){this._viewLineOptions=t;const e=this._visibleLines.getStartLineNumber(),i=this._visibleLines.getEndLineNumber();for(let t=e;t<=i;t++){this._visibleLines.getVisibleLine(t).onOptionsChanged(this._viewLineOptions)}return!0}return!1}onCursorStateChanged(e){const t=this._visibleLines.getStartLineNumber(),i=this._visibleLines.getEndLineNumber();let s=!1;for(let n=t;n<=i;n++)s=this._visibleLines.getVisibleLine(n).onSelectionChanged()||s;return s}onDecorationsChanged(e){{const e=this._visibleLines.getStartLineNumber(),t=this._visibleLines.getEndLineNumber();for(let i=e;i<=t;i++)this._visibleLines.getVisibleLine(i).onDecorationsChanged()}return!0}onFlushed(e){const t=this._visibleLines.onFlushed(e);return this._maxLineWidth=0,t}onLinesChanged(e){return this._visibleLines.onLinesChanged(e)}onLinesDeleted(e){return this._visibleLines.onLinesDeleted(e)}onLinesInserted(e){return this._visibleLines.onLinesInserted(e)}onRevealRangeRequest(e){const t=this._computeScrollTopToRevealRange(this._context.viewLayout.getFutureViewport(),e.source,e.minimalReveal,e.range,e.selections,e.verticalType);if(-1===t)return!1;let i=this._context.viewLayout.validateScrollPosition({scrollTop:t});e.revealHorizontal?e.range&&e.range.startLineNumber!==e.range.endLineNumber?i={scrollTop:i.scrollTop,scrollLeft:0}:e.range?this._horizontalRevealRequest=new Dt(e.minimalReveal,e.range.startLineNumber,e.range.startColumn,e.range.endColumn,this._context.viewLayout.getCurrentScrollTop(),i.scrollTop,e.scrollType):e.selections&&e.selections.length>0&&(this._horizontalRevealRequest=new Mt(e.minimalReveal,e.selections,this._context.viewLayout.getCurrentScrollTop(),i.scrollTop,e.scrollType)):this._horizontalRevealRequest=null;const s=Math.abs(this._context.viewLayout.getCurrentScrollTop()-i.scrollTop)<=this._lineHeight?1:e.scrollType;return this._context.viewModel.viewLayout.setScrollPosition(i,s),!0}onScrollChanged(e){if(this._horizontalRevealRequest&&e.scrollLeftChanged&&(this._horizontalRevealRequest=null),this._horizontalRevealRequest&&e.scrollTopChanged){const t=Math.min(this._horizontalRevealRequest.startScrollTop,this._horizontalRevealRequest.stopScrollTop),i=Math.max(this._horizontalRevealRequest.startScrollTop,this._horizontalRevealRequest.stopScrollTop);(e.scrollTopi)&&(this._horizontalRevealRequest=null)}return this.domNode.setWidth(e.scrollWidth),this._visibleLines.onScrollChanged(e)||!0}onTokensChanged(e){return this._visibleLines.onTokensChanged(e)}onZonesChanged(e){return this._context.viewModel.viewLayout.setMaxLineWidth(this._maxLineWidth),this._visibleLines.onZonesChanged(e)}onThemeChanged(e){return this._onOptionsMaybeChanged()}getPositionFromDOMInfo(e,t){const i=this._getViewLineDomNode(e);if(null===i)return null;const s=this._getLineNumberFor(i);if(-1===s)return null;if(s<1||s>this._context.viewModel.getLineCount())return null;if(1===this._context.viewModel.getLineMaxColumn(s))return new Y.y(s,1);const n=this._visibleLines.getStartLineNumber(),r=this._visibleLines.getEndLineNumber();if(sr)return null;let o=this._visibleLines.getVisibleLine(s).getColumnOfNodeOffset(e,t);const a=this._context.viewModel.getLineMinColumn(s);return oi)return-1;const s=new It(this.domNode.domNode,this._textRangeRestingSpot),n=this._visibleLines.getVisibleLine(e).getWidth(s);return this._updateLineWidthsSlowIfDomDidLayout(s),n}linesVisibleRangesForRange(e,t){if(this.shouldRender())return null;const i=e.endLineNumber,s=q.Q.intersectRanges(e,this._lastRenderedData.getCurrentVisibleRange());if(!s)return null;const n=[];let r=0;const o=new It(this.domNode.domNode,this._textRangeRestingSpot);let a=0;t&&(a=this._context.viewModel.coordinatesConverter.convertViewPositionToModelPosition(new Y.y(s.startLineNumber,1)).lineNumber);const l=this._visibleLines.getStartLineNumber(),c=this._visibleLines.getEndLineNumber();for(let h=s.startLineNumber;h<=s.endLineNumber;h++){if(hc)continue;const e=h===s.startLineNumber?s.startColumn:1,d=h!==s.endLineNumber,u=d?this._context.viewModel.getLineMaxColumn(h):s.endColumn,g=this._visibleLines.getVisibleLine(h).getVisibleRangesForRange(h,e,u,o);if(g){if(t&&hthis._visibleLines.getEndLineNumber())return null;const s=new It(this.domNode.domNode,this._textRangeRestingSpot),n=this._visibleLines.getVisibleLine(e).getVisibleRangesForRange(e,t,i,s);return this._updateLineWidthsSlowIfDomDidLayout(s),n}visibleRangeForPosition(e){const t=this._visibleRangesForLineRange(e.lineNumber,e.column,e.column);return t?new je.qN(t.outsideRenderedLine,t.ranges[0].left):null}_updateLineWidthsFast(){return this._updateLineWidths(!0)}_updateLineWidthsSlow(){this._updateLineWidths(!1)}_updateLineWidthsSlowIfDomDidLayout(e){e.didDomLayout&&(this._asyncUpdateLineWidths.isScheduled()||(this._asyncUpdateLineWidths.cancel(),this._updateLineWidthsSlow()))}_updateLineWidths(e){const t=this._visibleLines.getStartLineNumber(),i=this._visibleLines.getEndLineNumber();let s=1,n=!0;for(let r=t;r<=i;r++){const t=this._visibleLines.getVisibleLine(r);!e||t.getWidthIsFast()?s=Math.max(s,t.getWidth(null)):n=!1}return n&&1===t&&i===this._context.viewModel.getLineCount()&&(this._maxLineWidth=0),this._ensureMaxLineWidth(s),n}_checkMonospaceFontAssumptions(){let e=-1,t=-1;const i=this._visibleLines.getStartLineNumber(),s=this._visibleLines.getEndLineNumber();for(let n=i;n<=s;n++){const i=this._visibleLines.getVisibleLine(n);if(i.needsMonospaceFontCheck()){const s=i.getWidth(null);s>t&&(t=s,e=n)}}if(-1!==e&&!this._visibleLines.getVisibleLine(e).monospaceAssumptionsAreValid())for(let n=i;n<=s;n++){this._visibleLines.getVisibleLine(n).onMonospaceAssumptionsInvalidated()}}prepareRender(){throw new Error("Not supported")}render(){throw new Error("Not supported")}renderText(e){if(this._visibleLines.renderLines(e),this._lastRenderedData.setCurrentVisibleRange(e.visibleRange),this.domNode.setWidth(this._context.viewLayout.getScrollWidth()),this.domNode.setHeight(Math.min(this._context.viewLayout.getScrollHeight(),1e6)),this._horizontalRevealRequest){const t=this._horizontalRevealRequest;if(e.startLineNumber<=t.minLineNumber&&t.maxLineNumber<=e.endLineNumber){this._horizontalRevealRequest=null,this.onDidRender();const e=this._computeScrollLeftToReveal(t);e&&(this._isViewportWrapping||this._ensureMaxLineWidth(e.maxHorizontalOffset),this._context.viewModel.viewLayout.setScrollPosition({scrollLeft:e.scrollLeft},t.scrollType))}}if(this._updateLineWidthsFast()?this._asyncUpdateLineWidths.cancel():this._asyncUpdateLineWidths.schedule(),_.j9&&!this._asyncCheckMonospaceFontAssumptions.isScheduled()){const e=this._visibleLines.getStartLineNumber(),t=this._visibleLines.getEndLineNumber();for(let i=e;i<=t;i++){if(this._visibleLines.getVisibleLine(i).needsMonospaceFontCheck()){this._asyncCheckMonospaceFontAssumptions.schedule();break}}}this._linesContent.setLayerHinting(this._canUseLayerHinting),this._linesContent.setContain("strict");const t=this._context.viewLayout.getCurrentScrollTop()-e.bigNumbersDelta;this._linesContent.setTop(-t),this._linesContent.setLeft(-this._context.viewLayout.getCurrentScrollLeft())}_ensureMaxLineWidth(e){const t=Math.ceil(e);this._maxLineWidth0){let e=n[0].startLineNumber,t=n[0].endLineNumber;for(let i=1,s=n.length;ia){if(!c)return-1;u=h}else if(5===r||6===r)if(6===r&&o<=h&&d<=l)u=o;else{const e=h-Math.max(5*this._lineHeight,.2*a),t=d-a;u=Math.max(t,e)}else if(1===r||2===r)if(2===r&&o<=h&&d<=l)u=o;else{const e=(h+d)/2;u=Math.max(0,e-a/2)}else u=this._computeMinimumScrolling(o,l,h,d,3===r,4===r);return u}_computeScrollLeftToReveal(e){const t=this._context.viewLayout.getCurrentViewport(),i=this._context.configuration.options.get(146),s=t.left,n=s+t.width-i.verticalScrollbarWidth;let r=1073741824,o=0;if("range"===e.type){const t=this._visibleRangesForLineRange(e.lineNumber,e.startColumn,e.endColumn);if(!t)return null;for(const e of t.ranges)r=Math.min(r,Math.round(e.left)),o=Math.max(o,Math.round(e.left+e.width))}else for(const a of e.selections){if(a.startLineNumber!==a.endLineNumber)return null;const e=this._visibleRangesForLineRange(a.startLineNumber,a.startColumn,a.endColumn);if(!e)return null;for(const t of e.ranges)r=Math.min(r,Math.round(t.left)),o=Math.max(o,Math.round(t.left+t.width))}if(e.minimalReveal||(r=Math.max(0,r-Pt.HORIZONTAL_EXTRA_PX),o+=this._revealHorizontalRightPadding),"selections"===e.type&&o-r>t.width)return null;return{scrollLeft:this._computeMinimumScrolling(s,n,r,o),maxHorizontalOffset:o}}_computeMinimumScrolling(e,t,i,s,n,r){n=!!n,r=!!r;const o=(t|=0)-(e|=0);return(s|=0)-(i|=0)t?Math.max(0,s-o):e:i}}class Ft extends Et{constructor(e){super(),this._context=e;const t=this._context.configuration.options.get(146);this._decorationsLeft=t.decorationsLeft,this._decorationsWidth=t.decorationsWidth,this._renderResult=null,this._context.addEventHandler(this)}dispose(){this._context.removeEventHandler(this),this._renderResult=null,super.dispose()}onConfigurationChanged(e){const t=this._context.configuration.options.get(146);return this._decorationsLeft=t.decorationsLeft,this._decorationsWidth=t.decorationsWidth,!0}onDecorationsChanged(e){return!0}onFlushed(e){return!0}onLinesChanged(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return e.scrollTopChanged}onZonesChanged(e){return!0}_getDecorations(e){const t=e.getDecorationsInViewport(),i=[];let s=0;for(let n=0,r=t.length;n',r=[];for(let o=t;o<=i;o++){const e=o-t,i=s[e].getDecorations();let a="";for(const t of i){let e='
    ';n[e]=o}this._renderResult=n}render(e,t){return this._renderResult?this._renderResult[t-e]:""}}var Ht=i(34072);class Bt{static{this.Empty=new Bt(0,0,0,0)}constructor(e,t,i,s){this._rgba8Brand=void 0,this.r=Bt._clamp(e),this.g=Bt._clamp(t),this.b=Bt._clamp(i),this.a=Bt._clamp(s)}equals(e){return this.r===e.r&&this.g===e.g&&this.b===e.b&&this.a===e.a}static _clamp(e){return e<0?0:e>255?255:0|e}}class Wt extends d.jG{static{this._INSTANCE=null}static getInstance(){return this._INSTANCE||(this._INSTANCE=(0,d.lC)(new Wt)),this._INSTANCE}constructor(){super(),this._onDidChange=new h.vl,this.onDidChange=this._onDidChange.event,this._updateColorMap(),this._register(Me.dG.onDidChange((e=>{e.changedColorMap&&this._updateColorMap()})))}_updateColorMap(){const e=Me.dG.getColorMap();if(!e)return this._colors=[Bt.Empty],void(this._backgroundIsLight=!0);this._colors=[Bt.Empty];for(let i=1;i=.5,this._onDidChange.fire(void 0)}getColor(e){return(e<1||e>=this._colors.length)&&(e=2),this._colors[e]}backgroundIsLight(){return this._backgroundIsLight}}var Vt=i(92896),zt=i(66261);const Gt=(()=>{const e=[];for(let t=32;t<=126;t++)e.push(t);return e.push(65533),e})();var jt=i(85152);class Kt{constructor(e,t){this.scale=t,this._minimapCharRendererBrand=void 0,this.charDataNormal=Kt.soften(e,.8),this.charDataLight=Kt.soften(e,50/60)}static soften(e,t){const i=new Uint8ClampedArray(e.length);for(let s=0,n=e.length;se.width||i+g>e.height)return void console.warn("bad render request outside image data");const p=c?this.charDataLight:this.charDataNormal,m=((e,t)=>(e-=32)<0||e>96?t<=2?(e+96)%96:95:e)(s,l),f=4*e.width,_=o.r,v=o.g,C=o.b,b=n.r-_,E=n.g-v,S=n.b-C,y=Math.max(r,a),w=e.data;let L=m*d*u,R=i*f+4*t;for(let T=0;Te.width||i+h>e.height)return void console.warn("bad render request outside image data");const d=4*e.width,u=n/255*.5,g=r.r,p=r.g,m=r.b,f=g+(s.r-g)*u,_=p+(s.g-p)*u,v=m+(s.b-m)*u,C=Math.max(n,o),b=e.data;let E=i*d+4*t;for(let S=0;S{const t=new Uint8ClampedArray(e.length/2);for(let i=0;i>1]=qt[e[i]]<<4|15&qt[e[i+1]];return t},Qt={1:(0,Yt.P)((()=>$t("0000511D6300CF609C709645A78432005642574171487021003C451900274D35D762755E8B629C5BA856AF57BA649530C167D1512A272A3F6038604460398526BCA2A968DB6F8957C768BE5FBE2FB467CF5D8D5B795DC7625B5DFF50DE64C466DB2FC47CD860A65E9A2EB96CB54CE06DA763AB2EA26860524D3763536601005116008177A8705E53AB738E6A982F88BAA35B5F5B626D9C636B449B737E5B7B678598869A662F6B5B8542706C704C80736A607578685B70594A49715A4522E792"))),2:(0,Yt.P)((()=>$t("000000000000000055394F383D2800008B8B1F210002000081B1CBCBCC820000847AAF6B9AAF2119BE08B8881AD60000A44FD07DCCF107015338130C00000000385972265F390B406E2437634B4B48031B12B8A0847000001E15B29A402F0000000000004B33460B00007A752C2A0000000000004D3900000084394B82013400ABA5CFC7AD9C0302A45A3E5A98AB000089A43382D97900008BA54AA087A70A0248A6A7AE6DBE0000BF6F94987EA40A01A06DCFA7A7A9030496C32F77891D0000A99FB1A0AFA80603B29AB9CA75930D010C0948354D3900000C0948354F37460D0028BE673D8400000000AF9D7B6E00002B007AA8933400007AA642675C2700007984CFB9C3985B768772A8A6B7B20000CAAECAAFC4B700009F94A6009F840009D09F9BA4CA9C0000CC8FC76DC87F0000C991C472A2000000A894A48CA7B501079BA2C9C69BA20000B19A5D3FA89000005CA6009DA2960901B0A7F0669FB200009D009E00B7890000DAD0F5D092820000D294D4C48BD10000B5A7A4A3B1A50402CAB6CBA6A2000000B5A7A4A3B1A8044FCDADD19D9CB00000B7778F7B8AAE0803C9AB5D3F5D3F00009EA09EA0BAB006039EA0989A8C7900009B9EF4D6B7C00000A9A7816CACA80000ABAC84705D3F000096DA635CDC8C00006F486F266F263D4784006124097B00374F6D2D6D2D6D4A3A95872322000000030000000000008D8939130000000000002E22A5C9CBC70600AB25C0B5C9B400061A2DB04CA67001082AA6BEBEBFC606002321DACBC19E03087AA08B6768380000282FBAC0B8CA7A88AD25BBA5A29900004C396C5894A6000040485A6E356E9442A32CD17EADA70000B4237923628600003E2DE9C1D7B500002F25BBA5A2990000231DB6AFB4A804023025C0B5CAB588062B2CBDBEC0C706882435A75CA20000002326BD6A82A908048B4B9A5A668000002423A09CB4BB060025259C9D8A7900001C1FCAB2C7C700002A2A9387ABA200002626A4A47D6E9D14333163A0C87500004B6F9C2D643A257049364936493647358A34438355497F1A0000A24C1D590000D38DFFBDD4CD3126")))};class Xt{static create(e,t){if(this.lastCreated&&e===this.lastCreated.scale&&t===this.lastFontFamily)return this.lastCreated;let i;return i=Qt[e]?new Kt(Qt[e](),e):Xt.createFromSampleData(Xt.createSampleData(t).data,e),this.lastFontFamily=t,this.lastCreated=i,i}static createSampleData(e){const t=document.createElement("canvas"),i=t.getContext("2d");t.style.height="16px",t.height=16,t.width=960,t.style.width="960px",i.fillStyle="#ffffff",i.font=`bold 16px ${e}`,i.textBaseline="middle";let s=0;for(const n of Gt)i.fillText(String.fromCharCode(n),s,8),s+=10;return i.getImageData(0,0,960,16)}static createFromSampleData(e,t){if(61440!==e.length)throw new Error("Unexpected source in MinimapCharRenderer");const i=Xt._downsample(e,t);return new Kt(i,t)}static _downsampleChar(e,t,i,s,n){const r=1*n,o=2*n;let a=s,l=0;for(let c=0;c0){const e=255/a;for(let t=0;tXt.create(this.fontScale,a.fontFamily))),this.defaultBackgroundColor=i.getColor(2),this.backgroundColor=ei._getMinimapBackground(t,this.defaultBackgroundColor),this.foregroundAlpha=ei._getMinimapForegroundOpacity(t)}static _getMinimapBackground(e,t){const i=e.getColor(zt.ILr);return i?new Bt(i.rgba.r,i.rgba.g,i.rgba.b,Math.round(255*i.rgba.a)):t}static _getMinimapForegroundOpacity(e){const t=e.getColor(zt.K1Z);return t?Bt._clamp(Math.round(255*t.rgba.a)):255}static _getSectionHeaderColor(e,t){const i=e.getColor(zt.By2);return i?new Bt(i.rgba.r,i.rgba.g,i.rgba.b,Math.round(255*i.rgba.a)):t}equals(e){return this.renderMinimap===e.renderMinimap&&this.size===e.size&&this.minimapHeightIsEditorHeight===e.minimapHeightIsEditorHeight&&this.scrollBeyondLastLine===e.scrollBeyondLastLine&&this.paddingTop===e.paddingTop&&this.paddingBottom===e.paddingBottom&&this.showSlider===e.showSlider&&this.autohide===e.autohide&&this.pixelRatio===e.pixelRatio&&this.typicalHalfwidthCharacterWidth===e.typicalHalfwidthCharacterWidth&&this.lineHeight===e.lineHeight&&this.minimapLeft===e.minimapLeft&&this.minimapWidth===e.minimapWidth&&this.minimapHeight===e.minimapHeight&&this.canvasInnerWidth===e.canvasInnerWidth&&this.canvasInnerHeight===e.canvasInnerHeight&&this.canvasOuterWidth===e.canvasOuterWidth&&this.canvasOuterHeight===e.canvasOuterHeight&&this.isSampling===e.isSampling&&this.editorHeight===e.editorHeight&&this.fontScale===e.fontScale&&this.minimapLineHeight===e.minimapLineHeight&&this.minimapCharWidth===e.minimapCharWidth&&this.sectionHeaderFontSize===e.sectionHeaderFontSize&&this.sectionHeaderLetterSpacing===e.sectionHeaderLetterSpacing&&this.defaultBackgroundColor&&this.defaultBackgroundColor.equals(e.defaultBackgroundColor)&&this.backgroundColor&&this.backgroundColor.equals(e.backgroundColor)&&this.foregroundAlpha===e.foregroundAlpha}}class ti{constructor(e,t,i,s,n,r,o,a,l){this.scrollTop=e,this.scrollHeight=t,this.sliderNeeded=i,this._computedSliderRatio=s,this.sliderTop=n,this.sliderHeight=r,this.topPaddingLineCount=o,this.startLineNumber=a,this.endLineNumber=l}getDesiredScrollTopFromDelta(e){return Math.round(this.scrollTop+e/this._computedSliderRatio)}getDesiredScrollTopFromTouchLocation(e){return Math.round((e-this.sliderHeight/2)/this._computedSliderRatio)}intersectWithViewport(e){const t=Math.max(this.startLineNumber,e.startLineNumber),i=Math.min(this.endLineNumber,e.endLineNumber);return t>i?null:[t,i]}getYForLineNumber(e,t){return+(e-this.startLineNumber+this.topPaddingLineCount)*t}static create(e,t,i,s,n,r,o,a,l,c,h){const d=e.pixelRatio,u=e.minimapLineHeight,g=Math.floor(e.canvasInnerHeight/u),p=e.lineHeight;if(e.minimapHeightIsEditorHeight){let t=a*e.lineHeight+e.paddingTop+e.paddingBottom;e.scrollBeyondLastLine&&(t+=Math.max(0,n-e.lineHeight-e.paddingBottom));const i=Math.max(1,Math.floor(n*n/t)),s=Math.max(0,e.minimapHeight-i),r=s/(c-n),h=l*r,d=s>0,u=Math.floor(e.canvasInnerHeight/e.minimapLineHeight),g=Math.floor(e.paddingTop/e.lineHeight);return new ti(l,c,d,r,h,i,g,1,Math.min(o,u))}let m;if(r&&i!==o){const e=i-t+1;m=Math.floor(e*u/d)}else{const e=n/p;m=Math.floor(e*u/d)}const f=Math.floor(e.paddingTop/p);let _,v=Math.floor(e.paddingBottom/p);if(e.scrollBeyondLastLine){const e=n/p;v=Math.max(v,e-1)}if(v>0){_=(f+o+v-n/p-1)*u/d}else _=Math.max(0,(f+o)*u/d-m);_=Math.min(e.minimapHeight-m,_);const C=_/(c-n),b=l*C;if(g>=f+o+v){return new ti(l,c,_>0,C,b,m,f,1,o)}{let i,n;i=t>1?t+f:Math.max(1,l/p);let r=Math.max(1,Math.floor(i-b*d/u));rl&&(r=Math.min(r,h.startLineNumber),n=Math.max(n,h.topPaddingLineCount)),h.scrollTop=e.paddingTop?(t-r+n+_)*u/d:l/e.paddingTop*(n+_)*u/d,new ti(l,c,!0,C,v,m,n,r,a)}}}class ii{static{this.INVALID=new ii(-1)}constructor(e){this.dy=e}onContentChanged(){this.dy=-1}onTokensChanged(){this.dy=-1}}class si{constructor(e,t,i){this.renderedLayout=e,this._imageData=t,this._renderedLines=new Qe({createLine:()=>ii.INVALID}),this._renderedLines._set(e.startLineNumber,i)}linesEquals(e){if(!this.scrollEquals(e))return!1;const t=this._renderedLines._get().lines;for(let i=0,s=t.length;i1){for(let t=0,i=s-1;t0&&this.minimapLines[i-1]>=e;)i--;let s=this.modelLineToMinimapLine(t)-1;for(;s+1t)return null}return[i+1,s+1]}decorationLineRangeToMinimapLineRange(e,t){let i=this.modelLineToMinimapLine(e),s=this.modelLineToMinimapLine(t);return e!==t&&s===i&&(s===this.minimapLines.length?i>1&&i--:s++),[i,s]}onLinesDeleted(e){const t=e.toLineNumber-e.fromLineNumber+1;let i=this.minimapLines.length,s=0;for(let n=this.minimapLines.length-1;n>=0&&!(this.minimapLines[n]=0&&!(this.minimapLines[i]0,scrollWidth:e.scrollWidth,scrollHeight:e.scrollHeight,viewportStartLineNumber:t,viewportEndLineNumber:i,viewportStartLineNumberVerticalOffset:e.getVerticalOffsetForLineNumber(t),scrollTop:e.scrollTop,scrollLeft:e.scrollLeft,viewportWidth:e.viewportWidth,viewportHeight:e.viewportHeight};this._actual.render(s)}_recreateLineSampling(){this._minimapSelections=null;const e=Boolean(this._samplingState),[t,i]=ri.compute(this.options,this._context.viewModel.getLineCount(),this._samplingState);if(this._samplingState=t,e&&this._samplingState)for(const s of i)switch(s.type){case"deleted":this._actual.onLinesDeleted(s.deleteFromLineNumber,s.deleteToLineNumber);break;case"inserted":this._actual.onLinesInserted(s.insertFromLineNumber,s.insertToLineNumber);break;case"flush":this._actual.onFlushed()}}getLineCount(){return this._samplingState?this._samplingState.minimapLines.length:this._context.viewModel.getLineCount()}getRealLineCount(){return this._context.viewModel.getLineCount()}getLineContent(e){return this._samplingState?this._context.viewModel.getLineContent(this._samplingState.minimapLines[e-1]):this._context.viewModel.getLineContent(e)}getLineMaxColumn(e){return this._samplingState?this._context.viewModel.getLineMaxColumn(this._samplingState.minimapLines[e-1]):this._context.viewModel.getLineMaxColumn(e)}getMinimapLinesRenderingData(e,t,i){if(this._samplingState){const s=[];for(let n=0,r=t-e+1;n!e.options.minimap?.sectionHeaderStyle));if(this._samplingState){const e=[];for(const t of i){if(!t.options.minimap)continue;const i=t.range,s=this._samplingState.modelLineToMinimapLine(i.startLineNumber),n=this._samplingState.modelLineToMinimapLine(i.endLineNumber);e.push(new Vt.vo(new q.Q(s,i.startColumn,n,i.endColumn),t.options))}return e}return i}getSectionHeaderDecorationsInViewport(e,t){const i=this.options.minimapLineHeight,s=this.options.sectionHeaderFontSize/i;return e=Math.floor(Math.max(1,e-s)),this._getMinimapDecorationsInViewport(e,t).filter((e=>!!e.options.minimap?.sectionHeaderStyle))}_getMinimapDecorationsInViewport(e,t){let i;if(this._samplingState){const s=this._samplingState.minimapLines[e-1],n=this._samplingState.minimapLines[t-1];i=new q.Q(s,1,n,this._context.viewModel.getLineMaxColumn(n))}else i=new q.Q(e,1,t,this._context.viewModel.getLineMaxColumn(t));return this._context.viewModel.getMinimapDecorationsInRange(i)}getSectionHeaderText(e,t){const i=e.options.minimap?.sectionHeaderText;if(!i)return null;const s=this._sectionHeaderCache.get(i);if(s)return s;const n=t(i);return this._sectionHeaderCache.set(i,n),n}getOptions(){return this._context.viewModel.model.getOptions()}revealLineNumber(e){this._samplingState&&(e=this._samplingState.minimapLines[e-1]),this._context.viewModel.revealRange("mouse",!1,new q.Q(e,1,e,1),1,0)}setScrollTop(e){this._context.viewModel.viewLayout.setScrollPosition({scrollTop:e},1)}}class ai extends d.jG{constructor(e,t){super(),this._renderDecorations=!1,this._gestureInProgress=!1,this._theme=e,this._model=t,this._lastRenderData=null,this._buffers=null,this._selectionColor=this._theme.getColor(zt.yr0),this._domNode=(0,H.Z)(document.createElement("div")),G.write(this._domNode,9),this._domNode.setClassName(this._getMinimapDomNodeClassName()),this._domNode.setPosition("absolute"),this._domNode.setAttribute("role","presentation"),this._domNode.setAttribute("aria-hidden","true"),this._shadow=(0,H.Z)(document.createElement("div")),this._shadow.setClassName("minimap-shadow-hidden"),this._domNode.appendChild(this._shadow),this._canvas=(0,H.Z)(document.createElement("canvas")),this._canvas.setPosition("absolute"),this._canvas.setLeft(0),this._domNode.appendChild(this._canvas),this._decorationsCanvas=(0,H.Z)(document.createElement("canvas")),this._decorationsCanvas.setPosition("absolute"),this._decorationsCanvas.setClassName("minimap-decorations-layer"),this._decorationsCanvas.setLeft(0),this._domNode.appendChild(this._decorationsCanvas),this._slider=(0,H.Z)(document.createElement("div")),this._slider.setPosition("absolute"),this._slider.setClassName("minimap-slider"),this._slider.setLayerHinting(!0),this._slider.setContain("strict"),this._domNode.appendChild(this._slider),this._sliderHorizontal=(0,H.Z)(document.createElement("div")),this._sliderHorizontal.setPosition("absolute"),this._sliderHorizontal.setClassName("minimap-slider-horizontal"),this._slider.appendChild(this._sliderHorizontal),this._applyLayout(),this._pointerDownListener=l.b2(this._domNode.domNode,l.Bx.POINTER_DOWN,(e=>{e.preventDefault();if(0===this._model.options.renderMinimap)return;if(!this._lastRenderData)return;if("proportional"!==this._model.options.size){if(0===e.button&&this._lastRenderData){const t=l.BK(this._slider.domNode),i=t.top+t.height/2;this._startSliderDragging(e,i,this._lastRenderData.renderedLayout)}return}const t=this._model.options.minimapLineHeight,i=this._model.options.canvasInnerHeight/this._model.options.canvasOuterHeight*e.offsetY;let s=Math.floor(i/t)+this._lastRenderData.renderedLayout.startLineNumber-this._lastRenderData.renderedLayout.topPaddingLineCount;s=Math.min(s,this._model.getLineCount()),this._model.revealLineNumber(s)})),this._sliderPointerMoveMonitor=new Ht._,this._sliderPointerDownListener=l.b2(this._slider.domNode,l.Bx.POINTER_DOWN,(e=>{e.preventDefault(),e.stopPropagation(),0===e.button&&this._lastRenderData&&this._startSliderDragging(e,e.pageY,this._lastRenderData.renderedLayout)})),this._gestureDisposable=de.q.addTarget(this._domNode.domNode),this._sliderTouchStartListener=l.ko(this._domNode.domNode,de.B.Start,(e=>{e.preventDefault(),e.stopPropagation(),this._lastRenderData&&(this._slider.toggleClassName("active",!0),this._gestureInProgress=!0,this.scrollDueToTouchEvent(e))}),{passive:!1}),this._sliderTouchMoveListener=l.ko(this._domNode.domNode,de.B.Change,(e=>{e.preventDefault(),e.stopPropagation(),this._lastRenderData&&this._gestureInProgress&&this.scrollDueToTouchEvent(e)}),{passive:!1}),this._sliderTouchEndListener=l.b2(this._domNode.domNode,de.B.End,(e=>{e.preventDefault(),e.stopPropagation(),this._gestureInProgress=!1,this._slider.toggleClassName("active",!1)}))}_startSliderDragging(e,t,i){if(!e.target||!(e.target instanceof Element))return;const s=e.pageX;this._slider.toggleClassName("active",!0);const n=(e,n)=>{const r=l.BK(this._domNode.domNode),o=Math.min(Math.abs(n-s),Math.abs(n-r.left),Math.abs(n-r.left-r.width));if(_.uF&&o>140)return void this._model.setScrollTop(i.scrollTop);const a=e-t;this._model.setScrollTop(i.getDesiredScrollTopFromDelta(a))};e.pageY!==t&&n(e.pageY,s),this._sliderPointerMoveMonitor.startMonitoring(e.target,e.pointerId,e.buttons,(e=>n(e.pageY,e.pageX)),(()=>{this._slider.toggleClassName("active",!1)}))}scrollDueToTouchEvent(e){const t=this._domNode.domNode.getBoundingClientRect().top,i=this._lastRenderData.renderedLayout.getDesiredScrollTopFromTouchLocation(e.pageY-t);this._model.setScrollTop(i)}dispose(){this._pointerDownListener.dispose(),this._sliderPointerMoveMonitor.dispose(),this._sliderPointerDownListener.dispose(),this._gestureDisposable.dispose(),this._sliderTouchStartListener.dispose(),this._sliderTouchMoveListener.dispose(),this._sliderTouchEndListener.dispose(),super.dispose()}_getMinimapDomNodeClassName(){const e=["minimap"];return"always"===this._model.options.showSlider?e.push("slider-always"):e.push("slider-mouseover"),this._model.options.autohide&&e.push("autohide"),e.join(" ")}getDomNode(){return this._domNode}_applyLayout(){this._domNode.setLeft(this._model.options.minimapLeft),this._domNode.setWidth(this._model.options.minimapWidth),this._domNode.setHeight(this._model.options.minimapHeight),this._shadow.setHeight(this._model.options.minimapHeight),this._canvas.setWidth(this._model.options.canvasOuterWidth),this._canvas.setHeight(this._model.options.canvasOuterHeight),this._canvas.domNode.width=this._model.options.canvasInnerWidth,this._canvas.domNode.height=this._model.options.canvasInnerHeight,this._decorationsCanvas.setWidth(this._model.options.canvasOuterWidth),this._decorationsCanvas.setHeight(this._model.options.canvasOuterHeight),this._decorationsCanvas.domNode.width=this._model.options.canvasInnerWidth,this._decorationsCanvas.domNode.height=this._model.options.canvasInnerHeight,this._slider.setWidth(this._model.options.minimapWidth)}_getBuffer(){return this._buffers||this._model.options.canvasInnerWidth>0&&this._model.options.canvasInnerHeight>0&&(this._buffers=new ni(this._canvas.domNode.getContext("2d"),this._model.options.canvasInnerWidth,this._model.options.canvasInnerHeight,this._model.options.backgroundColor)),this._buffers?this._buffers.getBuffer():null}onDidChangeOptions(){this._lastRenderData=null,this._buffers=null,this._applyLayout(),this._domNode.setClassName(this._getMinimapDomNodeClassName())}onSelectionChanged(){return this._renderDecorations=!0,!0}onDecorationsChanged(){return this._renderDecorations=!0,!0}onFlushed(){return this._lastRenderData=null,!0}onLinesChanged(e,t){return!!this._lastRenderData&&this._lastRenderData.onLinesChanged(e,t)}onLinesDeleted(e,t){return this._lastRenderData?.onLinesDeleted(e,t),!0}onLinesInserted(e,t){return this._lastRenderData?.onLinesInserted(e,t),!0}onScrollChanged(){return this._renderDecorations=!0,!0}onThemeChanged(){return this._selectionColor=this._theme.getColor(zt.yr0),this._renderDecorations=!0,!0}onTokensChanged(e){return!!this._lastRenderData&&this._lastRenderData.onTokensChanged(e)}onTokensColorsChanged(){return this._lastRenderData=null,this._buffers=null,!0}onZonesChanged(){return this._lastRenderData=null,!0}render(e){if(0===this._model.options.renderMinimap)return this._shadow.setClassName("minimap-shadow-hidden"),this._sliderHorizontal.setWidth(0),void this._sliderHorizontal.setHeight(0);e.scrollLeft+e.viewportWidth>=e.scrollWidth?this._shadow.setClassName("minimap-shadow-hidden"):this._shadow.setClassName("minimap-shadow-visible");const t=ti.create(this._model.options,e.viewportStartLineNumber,e.viewportEndLineNumber,e.viewportStartLineNumberVerticalOffset,e.viewportHeight,e.viewportContainsWhitespaceGaps,this._model.getLineCount(),this._model.getRealLineCount(),e.scrollTop,e.scrollHeight,this._lastRenderData?this._lastRenderData.renderedLayout:null);this._slider.setDisplay(t.sliderNeeded?"block":"none"),this._slider.setTop(t.sliderTop),this._slider.setHeight(t.sliderHeight),this._sliderHorizontal.setLeft(0),this._sliderHorizontal.setWidth(this._model.options.minimapWidth),this._sliderHorizontal.setTop(0),this._sliderHorizontal.setHeight(t.sliderHeight),this.renderDecorations(t),this._lastRenderData=this.renderLines(t)}renderDecorations(e){if(this._renderDecorations){this._renderDecorations=!1;const t=this._model.getSelections();t.sort(q.Q.compareRangesUsingStarts);const i=this._model.getMinimapDecorationsInViewport(e.startLineNumber,e.endLineNumber);i.sort(((e,t)=>(e.options.zIndex||0)-(t.options.zIndex||0)));const{canvasInnerWidth:s,canvasInnerHeight:n}=this._model.options,r=this._model.options.minimapLineHeight,o=this._model.options.minimapCharWidth,a=this._model.getOptions().tabSize,l=this._decorationsCanvas.domNode.getContext("2d");l.clearRect(0,0,s,n);const c=new li(e.startLineNumber,e.endLineNumber,!1);this._renderSelectionLineHighlights(l,t,c,e,r),this._renderDecorationsLineHighlights(l,i,c,e,r);const h=new li(e.startLineNumber,e.endLineNumber,null);this._renderSelectionsHighlights(l,t,h,e,r,a,o,s),this._renderDecorationsHighlights(l,i,h,e,r,a,o,s),this._renderSectionHeaders(e)}}_renderSelectionLineHighlights(e,t,i,s,n){if(!this._selectionColor||this._selectionColor.isTransparent())return;e.fillStyle=this._selectionColor.transparent(.5).toString();let r=0,o=0;for(const a of t){const t=s.intersectWithViewport(a);if(!t)continue;const[l,c]=t;for(let e=l;e<=c;e++)i.set(e,!0);const h=s.getYForLineNumber(l,n),d=s.getYForLineNumber(c,n);o>=h||(o>r&&e.fillRect(L.xq,r,e.canvas.width,o-r),r=h),o=d}o>r&&e.fillRect(L.xq,r,e.canvas.width,o-r)}_renderDecorationsLineHighlights(e,t,i,s,n){const r=new Map;for(let o=t.length-1;o>=0;o--){const a=t[o],l=a.options.minimap;if(!l||1!==l.position)continue;const c=s.intersectWithViewport(a.range);if(!c)continue;const[h,d]=c,u=l.getColor(this._theme.value);if(!u||u.isTransparent())continue;let g=r.get(u.toString());g||(g=u.transparent(.5).toString(),r.set(u.toString(),g)),e.fillStyle=g;for(let t=h;t<=d;t++){if(i.has(t))continue;i.set(t,!0);const r=s.getYForLineNumber(h,n);e.fillRect(L.xq,r,e.canvas.width,n)}}}_renderSelectionsHighlights(e,t,i,s,n,r,o,a){if(this._selectionColor&&!this._selectionColor.isTransparent())for(const l of t){const t=s.intersectWithViewport(l);if(!t)continue;const[c,h]=t;for(let d=c;d<=h;d++)this.renderDecorationOnLine(e,i,l,this._selectionColor,s,d,n,n,r,o,a)}}_renderDecorationsHighlights(e,t,i,s,n,r,o,a){for(const l of t){const t=l.options.minimap;if(!t)continue;const c=s.intersectWithViewport(l.range);if(!c)continue;const[h,d]=c,u=t.getColor(this._theme.value);if(u&&!u.isTransparent())for(let g=h;g<=d;g++)switch(t.position){case 1:this.renderDecorationOnLine(e,i,l.range,u,s,g,n,n,r,o,a);continue;case 2:{const t=s.getYForLineNumber(g,n),i=2;this.renderDecoration(e,u,i,t,2,n);continue}}}}renderDecorationOnLine(e,t,i,s,n,r,o,a,l,c,h){const d=n.getYForLineNumber(r,a);if(d+o<0||d>this._model.options.canvasInnerHeight)return;const{startLineNumber:u,endLineNumber:g}=i,p=u===r?i.startColumn:1,m=g===r?i.endColumn:this._model.getLineMaxColumn(r),f=this.getXOffsetForPosition(t,r,p,l,c,h),_=this.getXOffsetForPosition(t,r,m,l,c,h);this.renderDecoration(e,s,f,d,_-f,o)}getXOffsetForPosition(e,t,i,s,n,r){if(1===i)return L.xq;if((i-1)*n>=r)return r;let o=e.get(t);if(!o){const i=this._model.getLineContent(t);o=[L.xq];let a=L.xq;for(let e=1;e=r){o[e]=r;break}o[e]=l,a=l}e.set(t,o)}return i-1e.range.startLineNumber-t.range.startLineNumber));const g=ai._fitSectionHeader.bind(null,d,r-L.xq);for(const p of u){const s=e.getYForLineNumber(p.range.startLineNumber,t)+i,o=s-i,l=o+2,h=this._model.getSectionHeaderText(p,g);ai._renderSectionLabel(d,h,2===p.options.minimap?.sectionHeaderStyle,a,c,r,o,n,s,l)}}static _fitSectionHeader(e,t,i){if(!i)return i;const s=e.measureText(i).width,n=e.measureText("\u2026").width;if(s<=t||s<=n)return i;const r=i.length,o=s/i.length,a=Math.floor((t-n)/o)-1;let l=Math.ceil(a/2);for(;l>0&&/\s/.test(i[l-1]);)--l;return i.substring(0,l)+"\u2026"+i.substring(r-(a-l))}static _renderSectionLabel(e,t,i,s,n,r,o,a,l,c){t&&(e.fillStyle=s,e.fillRect(0,o,r,a),e.fillStyle=n,e.fillText(t,L.xq,l)),i&&(e.beginPath(),e.moveTo(0,c),e.lineTo(r,c),e.closePath(),e.stroke())}renderLines(e){const t=e.startLineNumber,i=e.endLineNumber,s=this._model.options.minimapLineHeight;if(this._lastRenderData&&this._lastRenderData.linesEquals(e)){const t=this._lastRenderData._get();return new si(e,t.imageData,t.lines)}const n=this._getBuffer();if(!n)return null;const[r,o,a]=ai._renderUntouchedLines(n,e.topPaddingLineCount,t,i,s,this._lastRenderData),l=this._model.getMinimapLinesRenderingData(t,i,a),c=this._model.getOptions().tabSize,h=this._model.options.defaultBackgroundColor,d=this._model.options.backgroundColor,u=this._model.options.foregroundAlpha,g=this._model.tokensColorTracker,p=g.backgroundIsLight(),m=this._model.options.renderMinimap,f=this._model.options.charRenderer(),_=this._model.options.fontScale,v=this._model.options.minimapCharWidth,C=(1===m?2:3)*_,b=s>C?Math.floor((s-C)/2):0,E=d.a/255,S=new Bt(Math.round((d.r-h.r)*E+h.r),Math.round((d.g-h.g)*E+h.g),Math.round((d.b-h.b)*E+h.b),255);let y=e.topPaddingLineCount*s;const w=[];for(let T=0,x=i-t+1;T=0&&t_)return;const o=m.charCodeAt(b);if(9===o){const e=d-(b+E)%d;E+=e-1,C+=e*r}else if(32===o)C+=r;else{const d=Re.ne(o)?2:1;for(let u=0;u_)return}}}}}class li{constructor(e,t,i){this._startLineNumber=e,this._endLineNumber=t,this._defaultValue=i,this._values=[];for(let s=0,n=this._endLineNumber-this._startLineNumber+1;sthis._endLineNumber||(this._values[e-this._startLineNumber]=t)}get(e){return ethis._endLineNumber?this._defaultValue:this._values[e-this._startLineNumber]}}class ci extends z{constructor(e,t){super(e),this._viewDomNode=t;const i=this._context.configuration.options.get(146);this._widgets={},this._verticalScrollbarWidth=i.verticalScrollbarWidth,this._minimapWidth=i.minimap.minimapWidth,this._horizontalScrollbarHeight=i.horizontalScrollbarHeight,this._editorHeight=i.height,this._editorWidth=i.width,this._viewDomNodeRect={top:0,left:0,width:0,height:0},this._domNode=(0,H.Z)(document.createElement("div")),G.write(this._domNode,4),this._domNode.setClassName("overlayWidgets"),this.overflowingOverlayWidgetsDomNode=(0,H.Z)(document.createElement("div")),G.write(this.overflowingOverlayWidgetsDomNode,5),this.overflowingOverlayWidgetsDomNode.setClassName("overflowingOverlayWidgets")}dispose(){super.dispose(),this._widgets={}}getDomNode(){return this._domNode}onConfigurationChanged(e){const t=this._context.configuration.options.get(146);return this._verticalScrollbarWidth=t.verticalScrollbarWidth,this._minimapWidth=t.minimap.minimapWidth,this._horizontalScrollbarHeight=t.horizontalScrollbarHeight,this._editorHeight=t.height,this._editorWidth=t.width,!0}addWidget(e){const t=(0,H.Z)(e.getDomNode());this._widgets[e.getId()]={widget:e,preference:null,domNode:t},t.setPosition("absolute"),t.setAttribute("widgetId",e.getId()),e.allowEditorOverflow?this.overflowingOverlayWidgetsDomNode.appendChild(t):this._domNode.appendChild(t),this.setShouldRender(),this._updateMaxMinWidth()}setWidgetPosition(e,t){const i=this._widgets[e.getId()],s=t?t.preference:null,n=t?.stackOridinal;return i.preference===s&&i.stack===n?(this._updateMaxMinWidth(),!1):(i.preference=s,i.stack=n,this.setShouldRender(),this._updateMaxMinWidth(),!0)}removeWidget(e){const t=e.getId();if(this._widgets.hasOwnProperty(t)){const e=this._widgets[t].domNode.domNode;delete this._widgets[t],e.remove(),this.setShouldRender(),this._updateMaxMinWidth()}}_updateMaxMinWidth(){let e=0;const t=Object.keys(this._widgets);for(let i=0,s=t.length;i0));t.sort(((e,t)=>(this._widgets[e].stack||0)-(this._widgets[t].stack||0)));for(let s=0,n=t.length;s=3){const t=Math.floor(s/3),i=Math.floor(s/3),n=s-t-i,r=e+t;return[[0,e,r,e,e+t+n,e,r,e],[0,t,n,t+n,i,t+n+i,n+i,t+n+i]]}if(2===i){const t=Math.floor(s/2),i=s-t;return[[0,e,e,e,e+t,e,e,e],[0,t,t,t,i,t+i,t+i,t+i]]}return[[0,e,e,e,e,e,e,e],[0,s,s,s,s,s,s,s]]}equals(e){return this.lineHeight===e.lineHeight&&this.pixelRatio===e.pixelRatio&&this.overviewRulerLanes===e.overviewRulerLanes&&this.renderBorder===e.renderBorder&&this.borderColor===e.borderColor&&this.hideCursor===e.hideCursor&&this.cursorColorSingle===e.cursorColorSingle&&this.cursorColorPrimary===e.cursorColorPrimary&&this.cursorColorSecondary===e.cursorColorSecondary&&this.themeType===e.themeType&&Pe.Q1.equals(this.backgroundColor,e.backgroundColor)&&this.top===e.top&&this.right===e.right&&this.domWidth===e.domWidth&&this.domHeight===e.domHeight&&this.canvasWidth===e.canvasWidth&&this.canvasHeight===e.canvasHeight}}class di extends z{constructor(e){super(e),this._actualShouldRender=0,this._renderedDecorations=[],this._renderedCursorPositions=[],this._domNode=(0,H.Z)(document.createElement("canvas")),this._domNode.setClassName("decorationsOverviewRuler"),this._domNode.setPosition("absolute"),this._domNode.setLayerHinting(!0),this._domNode.setContain("strict"),this._domNode.setAttribute("aria-hidden","true"),this._updateSettings(!1),this._tokensColorTrackerListener=Me.dG.onDidChange((e=>{e.changedColorMap&&this._updateSettings(!0)})),this._cursorPositions=[{position:new Y.y(1,1),color:this._settings.cursorColorSingle}]}dispose(){super.dispose(),this._tokensColorTrackerListener.dispose()}_updateSettings(e){const t=new hi(this._context.configuration,this._context.theme);return(!this._settings||!this._settings.equals(t))&&(this._settings=t,this._domNode.setTop(this._settings.top),this._domNode.setRight(this._settings.right),this._domNode.setWidth(this._settings.domWidth),this._domNode.setHeight(this._settings.domHeight),this._domNode.domNode.width=this._settings.canvasWidth,this._domNode.domNode.height=this._settings.canvasHeight,e&&this._render(),!0)}_markRenderingIsNeeded(){return this._actualShouldRender=2,!0}_markRenderingIsMaybeNeeded(){return this._actualShouldRender=1,!0}onConfigurationChanged(e){return!!this._updateSettings(!1)&&this._markRenderingIsNeeded()}onCursorStateChanged(e){this._cursorPositions=[];for(let t=0,i=e.selections.length;t1&&(s=0===t?this._settings.cursorColorPrimary:this._settings.cursorColorSecondary),this._cursorPositions.push({position:e.selections[t].getPosition(),color:s})}return this._cursorPositions.sort(((e,t)=>Y.y.compare(e.position,t.position))),this._markRenderingIsMaybeNeeded()}onDecorationsChanged(e){return!!e.affectsOverviewRuler&&this._markRenderingIsMaybeNeeded()}onFlushed(e){return this._markRenderingIsNeeded()}onScrollChanged(e){return!!e.scrollHeightChanged&&this._markRenderingIsNeeded()}onZonesChanged(e){return this._markRenderingIsNeeded()}onThemeChanged(e){return!!this._updateSettings(!1)&&this._markRenderingIsNeeded()}getDomNode(){return this._domNode.domNode}prepareRender(e){}render(e){this._render(),this._actualShouldRender=0}_render(){const e=this._settings.backgroundColor;if(0===this._settings.overviewRulerLanes)return this._domNode.setBackgroundColor(e?Pe.Q1.Format.CSS.formatHexA(e):""),void this._domNode.setDisplay("none");const t=this._context.viewModel.getAllOverviewRulerDecorations(this._context.theme);if(t.sort(Vt.Uv.compareByRenderingProps),1!==this._actualShouldRender||Vt.Uv.equalsArr(this._renderedDecorations,t)||(this._actualShouldRender=2),1!==this._actualShouldRender||(0,m.aI)(this._renderedCursorPositions,this._cursorPositions,((e,t)=>e.position.lineNumber===t.position.lineNumber&&e.color===t.color))||(this._actualShouldRender=2),1===this._actualShouldRender)return;this._renderedDecorations=t,this._renderedCursorPositions=this._cursorPositions,this._domNode.setDisplay("block");const i=this._settings.canvasWidth,s=this._settings.canvasHeight,n=this._settings.lineHeight,r=this._context.viewLayout,o=s/this._context.viewLayout.getScrollHeight(),a=6*this._settings.pixelRatio|0,l=a/2|0,c=this._domNode.domNode.getContext("2d");e?e.isOpaque()?(c.fillStyle=Pe.Q1.Format.CSS.formatHexA(e),c.fillRect(0,0,i,s)):(c.clearRect(0,0,i,s),c.fillStyle=Pe.Q1.Format.CSS.formatHexA(e),c.fillRect(0,0,i,s)):c.clearRect(0,0,i,s);const h=this._settings.x,d=this._settings.w;for(const u of t){const e=u.color,t=u.data;c.fillStyle=e;let i=0,g=0,p=0;for(let u=0,m=t.length/3;us&&(e=s-l),_=e-l,v=e+l}_>p+1||e!==i?(0!==u&&c.fillRect(h[i],g,d[i],p-g),i=e,g=_,p=v):v>p&&(p=v)}c.fillRect(h[i],g,d[i],p-g)}if(!this._settings.hideCursor){const e=2*this._settings.pixelRatio|0,t=e/2|0,i=this._settings.x[7],n=this._settings.w[7];let a=-100,l=-100,h=null;for(let d=0,u=this._cursorPositions.length;ds&&(p=s-t);const m=p-t,f=m+e;m>l+1||u!==h?(0!==d&&h&&c.fillRect(i,a,n,l-a),a=m,l=f):f>l&&(l=f),h=u,c.fillStyle=u}h&&c.fillRect(i,a,n,l-a)}this._settings.renderBorder&&this._settings.borderColor&&this._settings.overviewRulerLanes>0&&(c.beginPath(),c.lineWidth=1,c.strokeStyle=this._settings.borderColor,c.moveTo(0,0),c.lineTo(0,s),c.moveTo(1,0),c.lineTo(i,0),c.stroke())}}var ui,gi=i(19531);class pi extends V{constructor(e,t){super(),this._context=e;const i=this._context.configuration.options;this._domNode=(0,H.Z)(document.createElement("canvas")),this._domNode.setClassName(t),this._domNode.setPosition("absolute"),this._domNode.setLayerHinting(!0),this._domNode.setContain("strict"),this._zoneManager=new gi.rW((e=>this._context.viewLayout.getVerticalOffsetForLineNumber(e))),this._zoneManager.setDOMWidth(0),this._zoneManager.setDOMHeight(0),this._zoneManager.setOuterHeight(this._context.viewLayout.getScrollHeight()),this._zoneManager.setLineHeight(i.get(67)),this._zoneManager.setPixelRatio(i.get(144)),this._context.addEventHandler(this)}dispose(){this._context.removeEventHandler(this),super.dispose()}onConfigurationChanged(e){const t=this._context.configuration.options;return e.hasChanged(67)&&(this._zoneManager.setLineHeight(t.get(67)),this._render()),e.hasChanged(144)&&(this._zoneManager.setPixelRatio(t.get(144)),this._domNode.setWidth(this._zoneManager.getDOMWidth()),this._domNode.setHeight(this._zoneManager.getDOMHeight()),this._domNode.domNode.width=this._zoneManager.getCanvasWidth(),this._domNode.domNode.height=this._zoneManager.getCanvasHeight(),this._render()),!0}onFlushed(e){return this._render(),!0}onScrollChanged(e){return e.scrollHeightChanged&&(this._zoneManager.setOuterHeight(e.scrollHeight),this._render()),!0}onZonesChanged(e){return this._render(),!0}getDomNode(){return this._domNode.domNode}setLayout(e){this._domNode.setTop(e.top),this._domNode.setRight(e.right);let t=!1;t=this._zoneManager.setDOMWidth(e.width)||t,t=this._zoneManager.setDOMHeight(e.height)||t,t&&(this._domNode.setWidth(this._zoneManager.getDOMWidth()),this._domNode.setHeight(this._zoneManager.getDOMHeight()),this._domNode.domNode.width=this._zoneManager.getCanvasWidth(),this._domNode.domNode.height=this._zoneManager.getCanvasHeight(),this._render())}setZones(e){this._zoneManager.setZones(e),this._render()}_render(){if(0===this._zoneManager.getOuterHeight())return!1;const e=this._zoneManager.getCanvasWidth(),t=this._zoneManager.getCanvasHeight(),i=this._zoneManager.resolveColorZones(),s=this._zoneManager.getId2Color(),n=this._domNode.domNode.getContext("2d");return n.clearRect(0,0,e,t),i.length>0&&this._renderOneLane(n,i,s,e),!0}_renderOneLane(e,t,i,s){let n=0,r=0,o=0;for(const a of t){const t=a.colorId,l=a.from,c=a.to;t!==n?(e.fillRect(0,r,s,o-r),n=t,e.fillStyle=i[n],r=l,o=c):o>=l?o=Math.max(o,c):(e.fillRect(0,r,s,o-r),r=l,o=c)}e.fillRect(0,r,s,o-r)}}class mi extends z{constructor(e){super(e),this.domNode=(0,H.Z)(document.createElement("div")),this.domNode.setAttribute("role","presentation"),this.domNode.setAttribute("aria-hidden","true"),this.domNode.setClassName("view-rulers"),this._renderedRulers=[];const t=this._context.configuration.options;this._rulers=t.get(103),this._typicalHalfwidthCharacterWidth=t.get(50).typicalHalfwidthCharacterWidth}dispose(){super.dispose()}onConfigurationChanged(e){const t=this._context.configuration.options;return this._rulers=t.get(103),this._typicalHalfwidthCharacterWidth=t.get(50).typicalHalfwidthCharacterWidth,!0}onScrollChanged(e){return e.scrollHeightChanged}prepareRender(e){}_ensureRulersCount(){const e=this._renderedRulers.length,t=this._rulers.length;if(e===t)return;if(e0;){const e=(0,H.Z)(document.createElement("div"));e.setClassName("view-ruler"),e.setWidth(s),this.domNode.appendChild(e),this._renderedRulers.push(e),n--}return}let i=e-t;for(;i>0;){const e=this._renderedRulers.pop();this.domNode.removeChild(e),i--}}render(e){this._ensureRulersCount();for(let t=0,i=this._rulers.length;t0;return this._shouldShow!==e&&(this._shouldShow=e,!0)}getDomNode(){return this._domNode}_updateWidth(){const e=this._context.configuration.options.get(146);0===e.minimap.renderMinimap||e.minimap.minimapWidth>0&&0===e.minimap.minimapLeft?this._width=e.width:this._width=e.width-e.verticalScrollbarWidth}onConfigurationChanged(e){const t=this._context.configuration.options.get(104);return this._useShadows=t.useShadows,this._updateWidth(),this._updateShouldShow(),!0}onScrollChanged(e){return this._scrollTop=e.scrollTop,this._updateShouldShow()}prepareRender(e){}render(e){this._domNode.setWidth(this._width),this._domNode.setClassName(this._shouldShow?"scroll-decoration":"")}}class _i{constructor(e){this.left=e.left,this.width=e.width,this.startStyle=null,this.endStyle=null}}class vi{constructor(e,t){this.lineNumber=e,this.ranges=t}}function Ci(e){return new _i(e)}function bi(e){return new vi(e.lineNumber,e.ranges.map(Ci))}class Ei extends xe{static{this.SELECTION_CLASS_NAME="selected-text"}static{this.SELECTION_TOP_LEFT="top-left-radius"}static{this.SELECTION_BOTTOM_LEFT="bottom-left-radius"}static{this.SELECTION_TOP_RIGHT="top-right-radius"}static{this.SELECTION_BOTTOM_RIGHT="bottom-right-radius"}static{this.EDITOR_BACKGROUND_CLASS_NAME="monaco-editor-background"}static{this.ROUNDED_PIECE_WIDTH=10}constructor(e){super(),this._previousFrameVisibleRangesWithStyle=[],this._context=e;const t=this._context.configuration.options;this._roundedSelection=t.get(102),this._typicalHalfwidthCharacterWidth=t.get(50).typicalHalfwidthCharacterWidth,this._selections=[],this._renderResult=null,this._context.addEventHandler(this)}dispose(){this._context.removeEventHandler(this),this._renderResult=null,super.dispose()}onConfigurationChanged(e){const t=this._context.configuration.options;return this._roundedSelection=t.get(102),this._typicalHalfwidthCharacterWidth=t.get(50).typicalHalfwidthCharacterWidth,!0}onCursorStateChanged(e){return this._selections=e.selections.slice(0),!0}onDecorationsChanged(e){return!0}onFlushed(e){return!0}onLinesChanged(e){return!0}onLinesDeleted(e){return!0}onLinesInserted(e){return!0}onScrollChanged(e){return e.scrollTopChanged}onZonesChanged(e){return!0}_visibleRangesHaveGaps(e){for(let t=0,i=e.length;t1)return!0}return!1}_enrichVisibleRangesWithStyle(e,t,i){const s=this._typicalHalfwidthCharacterWidth/4;let n=null,r=null;if(i&&i.length>0&&t.length>0){const s=t[0].lineNumber;if(s===e.startLineNumber)for(let e=0;!n&&e=0;e--)i[e].lineNumber===o&&(r=i[e].ranges[0]);n&&!n.startStyle&&(n=null),r&&!r.startStyle&&(r=null)}for(let o=0,a=t.length;o0){const e=t[o-1].ranges[0].left,n=t[o-1].ranges[0].left+t[o-1].ranges[0].width;Si(i-e)e&&(c.top=1),Si(l-n)'}_actualRenderOneSelection(e,t,i,s){if(0===s.length)return;const n=!!s[0].ranges[0].startStyle,r=s[0].lineNumber,o=s[s.length-1].lineNumber;for(let a=0,l=s.length;a1,o)}this._previousFrameVisibleRangesWithStyle=n,this._renderResult=t.map((([e,t])=>e+t))}render(e,t){if(!this._renderResult)return"";const i=t-e;return i<0||i>=this._renderResult.length?"":this._renderResult[i]}}function Si(e){return e<0?-e:e}(0,ke.zy)(((e,t)=>{const i=e.getColor(zt.rm4);i&&!i.isTransparent()&&t.addRule(`.monaco-editor .view-line span.inline-selected-text { color: ${i}; }`)}));class yi{constructor(e,t,i,s,n,r,o){this.top=e,this.left=t,this.paddingLeft=i,this.width=s,this.height=n,this.textContent=r,this.textContentClassName=o}}!function(e){e[e.Single=0]="Single",e[e.MultiPrimary=1]="MultiPrimary",e[e.MultiSecondary=2]="MultiSecondary"}(ui||(ui={}));class wi{constructor(e,t){this._context=e;const i=this._context.configuration.options,s=i.get(50);this._cursorStyle=i.get(28),this._lineHeight=i.get(67),this._typicalHalfwidthCharacterWidth=s.typicalHalfwidthCharacterWidth,this._lineCursorWidth=Math.min(i.get(31),this._typicalHalfwidthCharacterWidth),this._isVisible=!0,this._domNode=(0,H.Z)(document.createElement("div")),this._domNode.setClassName(`cursor ${De}`),this._domNode.setHeight(this._lineHeight),this._domNode.setTop(0),this._domNode.setLeft(0),(0,g.M)(this._domNode,s),this._domNode.setDisplay("none"),this._position=new Y.y(1,1),this._pluralityClass="",this.setPlurality(t),this._lastRenderedContent="",this._renderData=null}getDomNode(){return this._domNode}getPosition(){return this._position}setPlurality(e){switch(e){default:case ui.Single:this._pluralityClass="";break;case ui.MultiPrimary:this._pluralityClass="cursor-primary";break;case ui.MultiSecondary:this._pluralityClass="cursor-secondary"}}show(){this._isVisible||(this._domNode.setVisibility("inherit"),this._isVisible=!0)}hide(){this._isVisible&&(this._domNode.setVisibility("hidden"),this._isVisible=!1)}onConfigurationChanged(e){const t=this._context.configuration.options,i=t.get(50);return this._cursorStyle=t.get(28),this._lineHeight=t.get(67),this._typicalHalfwidthCharacterWidth=i.typicalHalfwidthCharacterWidth,this._lineCursorWidth=Math.min(t.get(31),this._typicalHalfwidthCharacterWidth),(0,g.M)(this._domNode,i),!0}onCursorPositionChanged(e,t){return this._domNode.domNode.style.transitionProperty=t?"none":"",this._position=e,!0}_getGraphemeAwarePosition(){const{lineNumber:e,column:t}=this._position,i=this._context.viewModel.getLineContent(e),[s,n]=Re.m(i,t-1);return[new Y.y(e,s+1),i.substring(s,n)]}_prepareRender(e){let t="",i="";const[s,n]=this._getGraphemeAwarePosition();if(this._cursorStyle===L.m9.Line||this._cursorStyle===L.m9.LineThin){const r=e.visibleRangeForPosition(s);if(!r||r.outsideRenderedLine)return null;const o=l.zk(this._domNode.domNode);let a;this._cursorStyle===L.m9.Line?(a=l.vT(o,this._lineCursorWidth>0?this._lineCursorWidth:2),a>2&&(t=n,i=this._getTokenClassName(s))):a=l.vT(o,1);let c=r.left,h=0;a>=2&&c>=1&&(h=1,c-=h);const d=e.getVerticalOffsetForLineNumber(s.lineNumber)-e.bigNumbersDelta;return new yi(d,c,h,a,this._lineHeight,t,i)}const r=e.linesVisibleRangesForRange(new q.Q(s.lineNumber,s.column,s.lineNumber,s.column+n.length),!1);if(!r||0===r.length)return null;const o=r[0];if(o.outsideRenderedLine||0===o.ranges.length)return null;const a=o.ranges[0],c="\t"===n||a.width<1?this._typicalHalfwidthCharacterWidth:a.width;this._cursorStyle===L.m9.Block&&(t=n,i=this._getTokenClassName(s));let h=e.getVerticalOffsetForLineNumber(s.lineNumber)-e.bigNumbersDelta,d=this._lineHeight;return this._cursorStyle!==L.m9.Underline&&this._cursorStyle!==L.m9.UnderlineThin||(h+=this._lineHeight-2,d=2),new yi(h,a.left,0,c,d,t,i)}_getTokenClassName(e){const t=this._context.viewModel.getViewLineData(e.lineNumber),i=t.tokens.findTokenIndexAtOffset(e.column-1);return t.tokens.getClassName(i)}prepareRender(e){this._renderData=this._prepareRender(e)}render(e){return this._renderData?(this._lastRenderedContent!==this._renderData.textContent&&(this._lastRenderedContent=this._renderData.textContent,this._domNode.domNode.textContent=this._lastRenderedContent),this._domNode.setClassName(`cursor ${this._pluralityClass} ${De} ${this._renderData.textContentClassName}`),this._domNode.setDisplay("block"),this._domNode.setTop(this._renderData.top),this._domNode.setLeft(this._renderData.left),this._domNode.setPaddingLeft(this._renderData.paddingLeft),this._domNode.setWidth(this._renderData.width),this._domNode.setLineHeight(this._renderData.height),this._domNode.setHeight(this._renderData.height),{domNode:this._domNode.domNode,position:this._position,contentLeft:this._renderData.left,height:this._renderData.height,width:2}):(this._domNode.setDisplay("none"),null)}}class Li extends z{static{this.BLINK_INTERVAL=500}constructor(e){super(e);const t=this._context.configuration.options;this._readOnly=t.get(92),this._cursorBlinking=t.get(26),this._cursorStyle=t.get(28),this._cursorSmoothCaretAnimation=t.get(27),this._selectionIsEmpty=!0,this._isComposingInput=!1,this._isVisible=!1,this._primaryCursor=new wi(this._context,ui.Single),this._secondaryCursors=[],this._renderData=[],this._domNode=(0,H.Z)(document.createElement("div")),this._domNode.setAttribute("role","presentation"),this._domNode.setAttribute("aria-hidden","true"),this._updateDomClassName(),this._domNode.appendChild(this._primaryCursor.getDomNode()),this._startCursorBlinkAnimation=new Nt.pc,this._cursorFlatBlinkInterval=new l.Be,this._blinkingEnabled=!1,this._editorHasFocus=!1,this._updateBlinking()}dispose(){super.dispose(),this._startCursorBlinkAnimation.dispose(),this._cursorFlatBlinkInterval.dispose()}getDomNode(){return this._domNode}onCompositionStart(e){return this._isComposingInput=!0,this._updateBlinking(),!0}onCompositionEnd(e){return this._isComposingInput=!1,this._updateBlinking(),!0}onConfigurationChanged(e){const t=this._context.configuration.options;this._readOnly=t.get(92),this._cursorBlinking=t.get(26),this._cursorStyle=t.get(28),this._cursorSmoothCaretAnimation=t.get(27),this._updateBlinking(),this._updateDomClassName(),this._primaryCursor.onConfigurationChanged(e);for(let i=0,s=this._secondaryCursors.length;it.length){const e=this._secondaryCursors.length-t.length;for(let t=0;t{for(let i=0,s=e.ranges.length;i{this._isVisible?this._hide():this._show()}),Li.BLINK_INTERVAL,(0,l.zk)(this._domNode.domNode)):this._startCursorBlinkAnimation.setIfNotSet((()=>{this._blinkingEnabled=!0,this._updateDomClassName()}),Li.BLINK_INTERVAL))}_updateDomClassName(){this._domNode.setClassName(this._getClassName())}_getClassName(){let e="cursors-layer";switch(this._selectionIsEmpty||(e+=" has-selection"),this._cursorStyle){case L.m9.Line:e+=" cursor-line-style";break;case L.m9.Block:e+=" cursor-block-style";break;case L.m9.Underline:e+=" cursor-underline-style";break;case L.m9.LineThin:e+=" cursor-line-thin-style";break;case L.m9.BlockOutline:e+=" cursor-block-outline-style";break;case L.m9.UnderlineThin:e+=" cursor-underline-thin-style";break;default:e+=" cursor-line-style"}if(this._blinkingEnabled)switch(this._getCursorBlinking()){case 1:e+=" cursor-blink";break;case 2:e+=" cursor-smooth";break;case 3:e+=" cursor-phase";break;case 4:e+=" cursor-expand";break;default:e+=" cursor-solid"}else e+=" cursor-solid";return"on"!==this._cursorSmoothCaretAnimation&&"explicit"!==this._cursorSmoothCaretAnimation||(e+=" cursor-smooth-caret-animation"),e}_show(){this._primaryCursor.show();for(let e=0,t=this._secondaryCursors.length;e{const i=[{class:".cursor",foreground:Ae.D0,background:Ae.kM},{class:".cursor-primary",foreground:Ae.sC,background:Ae.je},{class:".cursor-secondary",foreground:Ae.we,background:Ae.L0}];for(const s of i){const i=e.getColor(s.foreground);if(i){let n=e.getColor(s.background);n||(n=i.opposite()),t.addRule(`.monaco-editor .cursors-layer ${s.class} { background-color: ${i}; border-color: ${i}; color: ${n}; }`),(0,dt.Bb)(e.type)&&t.addRule(`.monaco-editor .cursors-layer.has-selection ${s.class} { border-left: 1px solid ${n}; border-right: 1px solid ${n}; }`)}}}));const Ri=()=>{throw new Error("Invalid change accessor")};class Ti extends z{constructor(e){super(e);const t=this._context.configuration.options,i=t.get(146);this._lineHeight=t.get(67),this._contentWidth=i.contentWidth,this._contentLeft=i.contentLeft,this.domNode=(0,H.Z)(document.createElement("div")),this.domNode.setClassName("view-zones"),this.domNode.setPosition("absolute"),this.domNode.setAttribute("role","presentation"),this.domNode.setAttribute("aria-hidden","true"),this.marginDomNode=(0,H.Z)(document.createElement("div")),this.marginDomNode.setClassName("margin-view-zones"),this.marginDomNode.setPosition("absolute"),this.marginDomNode.setAttribute("role","presentation"),this.marginDomNode.setAttribute("aria-hidden","true"),this._zones={}}dispose(){super.dispose(),this._zones={}}_recomputeWhitespacesProps(){const e=this._context.viewLayout.getWhitespaces(),t=new Map;for(const s of e)t.set(s.id,s);let i=!1;return this._context.viewModel.changeWhitespace((e=>{const s=Object.keys(this._zones);for(let n=0,r=s.length;n{const s={addZone:e=>(t=!0,this._addZone(i,e)),removeZone:e=>{e&&(t=this._removeZone(i,e)||t)},layoutZone:e=>{e&&(t=this._layoutZone(i,e)||t)}};!function(e,t){try{return e(t)}catch(i){(0,c.dz)(i)}}(e,s),s.addZone=Ri,s.removeZone=Ri,s.layoutZone=Ri})),t}_addZone(e,t){const i=this._computeWhitespaceProps(t),s={whitespaceId:e.insertWhitespace(i.afterViewLineNumber,this._getZoneOrdinal(t),i.heightInPx,i.minWidthInPx),delegate:t,isInHiddenArea:i.isInHiddenArea,isVisible:!1,domNode:(0,H.Z)(t.domNode),marginDomNode:t.marginDomNode?(0,H.Z)(t.marginDomNode):null};return this._safeCallOnComputedHeight(s.delegate,i.heightInPx),s.domNode.setPosition("absolute"),s.domNode.domNode.style.width="100%",s.domNode.setDisplay("none"),s.domNode.setAttribute("monaco-view-zone",s.whitespaceId),this.domNode.appendChild(s.domNode),s.marginDomNode&&(s.marginDomNode.setPosition("absolute"),s.marginDomNode.domNode.style.width="100%",s.marginDomNode.setDisplay("none"),s.marginDomNode.setAttribute("monaco-view-zone",s.whitespaceId),this.marginDomNode.appendChild(s.marginDomNode)),this._zones[s.whitespaceId]=s,this.setShouldRender(),s.whitespaceId}_removeZone(e,t){if(this._zones.hasOwnProperty(t)){const i=this._zones[t];return delete this._zones[t],e.removeWhitespace(i.whitespaceId),i.domNode.removeAttribute("monaco-visible-view-zone"),i.domNode.removeAttribute("monaco-view-zone"),i.domNode.domNode.remove(),i.marginDomNode&&(i.marginDomNode.removeAttribute("monaco-visible-view-zone"),i.marginDomNode.removeAttribute("monaco-view-zone"),i.marginDomNode.domNode.remove()),this.setShouldRender(),!0}return!1}_layoutZone(e,t){if(this._zones.hasOwnProperty(t)){const i=this._zones[t],s=this._computeWhitespaceProps(i.delegate);return i.isInHiddenArea=s.isInHiddenArea,e.changeOneWhitespace(i.whitespaceId,s.afterViewLineNumber,s.heightInPx),this._safeCallOnComputedHeight(i.delegate,s.heightInPx),this.setShouldRender(),!0}return!1}shouldSuppressMouseDownOnViewZone(e){if(this._zones.hasOwnProperty(e)){const t=this._zones[e];return Boolean(t.delegate.suppressMouseDown)}return!1}_heightInPixels(e){return"number"===typeof e.heightInPx?e.heightInPx:"number"===typeof e.heightInLines?this._lineHeight*e.heightInLines:this._lineHeight}_minWidthInPixels(e){return"number"===typeof e.minWidthInPx?e.minWidthInPx:0}_safeCallOnComputedHeight(e,t){if("function"===typeof e.onComputedHeight)try{e.onComputedHeight(t)}catch(i){(0,c.dz)(i)}}_safeCallOnDomNodeTop(e,t){if("function"===typeof e.onDomNodeTop)try{e.onDomNodeTop(t)}catch(i){(0,c.dz)(i)}}prepareRender(e){}render(e){const t=e.viewportData.whitespaceViewportData,i={};let s=!1;for(const r of t)this._zones[r.id].isInHiddenArea||(i[r.id]=r,s=!0);const n=Object.keys(this._zones);for(let r=0,o=n.length;rr)continue;const e=t.startLineNumber===r?t.startColumn:i.minColumn,n=t.endLineNumber===r?t.endColumn:i.maxColumn;e=y.endOffset&&(S++,y=i&&i[S]),9!==s&&32!==s)continue;if(d&&!b&&L<=v)continue;if(h&&L>=E&&L<=v&&32===s){const e=L-1>=0?o.charCodeAt(L-1):0,t=L+1=0?o.charCodeAt(L-1):0;if(32===s&&32!==e&&9!==e)continue}if(i&&(!y||y.startOffset>L||y.endOffset<=L))continue;const n=e.visibleRangeForPosition(new Y.y(t,L+1));n&&(r?(w=Math.max(w,n.left),C+=9===s?this._renderArrow(u,m,n.left):``):C+=9===s?`
    ${_?String.fromCharCode(65515):String.fromCharCode(8594)}
    `:`
    ${String.fromCharCode(f)}
    `)}return r?(w=Math.round(w+m),``+C+""):C}_renderArrow(e,t,i){const s=e/2,n=i,r={x:0,y:t/7/2},o={x:.8*t,y:r.y},a={x:o.x-.2*o.x,y:o.y+.2*o.x},l={x:a.x+.1*o.x,y:a.y+.1*o.x},c={x:l.x+.35*o.x,y:l.y-.35*o.x};return``}render(e,t){if(!this._renderResult)return"";const i=t-e;return i<0||i>=this._renderResult.length?"":this._renderResult[i]}}class Ai{constructor(e){const t=e.options,i=t.get(50),s=t.get(38);"off"===s?(this.renderWhitespace="none",this.renderWithSVG=!1):"svg"===s?(this.renderWhitespace=t.get(100),this.renderWithSVG=!0):(this.renderWhitespace=t.get(100),this.renderWithSVG=!1),this.spaceWidth=i.spaceWidth,this.middotWidth=i.middotWidth,this.wsmiddotWidth=i.wsmiddotWidth,this.canUseHalfwidthRightwardsArrow=i.canUseHalfwidthRightwardsArrow,this.lineHeight=t.get(67),this.stopRenderingLineAfter=t.get(118)}equals(e){return this.renderWhitespace===e.renderWhitespace&&this.renderWithSVG===e.renderWithSVG&&this.spaceWidth===e.spaceWidth&&this.middotWidth===e.middotWidth&&this.wsmiddotWidth===e.wsmiddotWidth&&this.canUseHalfwidthRightwardsArrow===e.canUseHalfwidthRightwardsArrow&&this.lineHeight===e.lineHeight&&this.stopRenderingLineAfter===e.stopRenderingLineAfter}}class Ni{constructor(e,t,i,s){this.selections=e,this.startLineNumber=0|t.startLineNumber,this.endLineNumber=0|t.endLineNumber,this.relativeVerticalOffset=t.relativeVerticalOffset,this.bigNumbersDelta=0|t.bigNumbersDelta,this.lineHeight=0|t.lineHeight,this.whitespaceViewportData=i,this._model=s,this.visibleRange=new q.Q(t.startLineNumber,this._model.getLineMinColumn(t.startLineNumber),t.endLineNumber,this._model.getLineMaxColumn(t.endLineNumber))}getViewLineRenderingData(e){return this._model.getViewportViewLineRenderingData(this.visibleRange,e)}getDecorationsInViewport(){return this._model.getDecorationsInViewport(this.visibleRange)}}class Ii{get type(){return this._theme.type}get value(){return this._theme}constructor(e){this._theme=e}update(e){this._theme=e}getColor(e){return this._theme.getColor(e)}}class Oi{constructor(e,t,i){this.configuration=e,this.theme=new Ii(t),this.viewModel=i,this.viewLayout=i.viewLayout}addEventHandler(e){this.viewModel.addViewEventHandler(e)}removeEventHandler(e){this.viewModel.removeViewEventHandler(e)}}var Di=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Mi=function(e,t){return function(i,s){t(i,s,e)}};let Pi=class extends V{constructor(e,t,i,s,n,r,o){super(),this._instantiationService=o,this._shouldRecomputeGlyphMarginLanes=!1,this._selections=[new pe.L(1,1,1,1)],this._renderAnimationFrame=null;const a=new Ye(t,s,n,e);this._context=new Oi(t,i,s),this._context.addEventHandler(this),this._viewParts=[],this._textAreaHandler=this._instantiationService.createInstance(Ge,this._context,a,this._createTextAreaHandlerHelper()),this._viewParts.push(this._textAreaHandler),this._linesContent=(0,H.Z)(document.createElement("div")),this._linesContent.setClassName("lines-content monaco-editor-background"),this._linesContent.setPosition("absolute"),this.domNode=(0,H.Z)(document.createElement("div")),this.domNode.setClassName(this._getEditorClassName()),this.domNode.setAttribute("role","code"),this._overflowGuardContainer=(0,H.Z)(document.createElement("div")),G.write(this._overflowGuardContainer,3),this._overflowGuardContainer.setClassName("overflow-guard"),this._scrollbar=new ft(this._context,this._linesContent,this.domNode,this._overflowGuardContainer),this._viewParts.push(this._scrollbar),this._viewLines=new Pt(this._context,this._linesContent),this._viewZones=new Ti(this._context),this._viewParts.push(this._viewZones);const l=new di(this._context);this._viewParts.push(l);const c=new fi(this._context);this._viewParts.push(c);const h=new tt(this._context);this._viewParts.push(h),h.addDynamicOverlay(new gt(this._context)),h.addDynamicOverlay(new Ei(this._context)),h.addDynamicOverlay(new kt(this._context)),h.addDynamicOverlay(new mt(this._context)),h.addDynamicOverlay(new ki(this._context));const d=new it(this._context);this._viewParts.push(d),d.addDynamicOverlay(new pt(this._context)),d.addDynamicOverlay(new Ut(this._context)),d.addDynamicOverlay(new Ft(this._context)),d.addDynamicOverlay(new Ne(this._context)),this._glyphMarginWidgets=new St(this._context),this._viewParts.push(this._glyphMarginWidgets);const u=new Ie(this._context);u.getDomNode().appendChild(this._viewZones.marginDomNode),u.getDomNode().appendChild(d.getDomNode()),u.getDomNode().appendChild(this._glyphMarginWidgets.domNode),this._viewParts.push(u),this._contentWidgets=new rt(this._context,this.domNode),this._viewParts.push(this._contentWidgets),this._viewCursors=new Li(this._context),this._viewParts.push(this._viewCursors),this._overlayWidgets=new ci(this._context,this.domNode),this._viewParts.push(this._overlayWidgets);const g=new mi(this._context);this._viewParts.push(g);const p=new nt(this._context);this._viewParts.push(p);const m=new oi(this._context);if(this._viewParts.push(m),l){const e=this._scrollbar.getOverviewRulerLayoutInfo();e.parent.insertBefore(l.getDomNode(),e.insertBefore)}this._linesContent.appendChild(h.getDomNode()),this._linesContent.appendChild(g.domNode),this._linesContent.appendChild(this._viewZones.domNode),this._linesContent.appendChild(this._viewLines.getDomNode()),this._linesContent.appendChild(this._contentWidgets.domNode),this._linesContent.appendChild(this._viewCursors.getDomNode()),this._overflowGuardContainer.appendChild(u.getDomNode()),this._overflowGuardContainer.appendChild(this._scrollbar.getDomNode()),this._overflowGuardContainer.appendChild(c.getDomNode()),this._overflowGuardContainer.appendChild(this._textAreaHandler.textArea),this._overflowGuardContainer.appendChild(this._textAreaHandler.textAreaCover),this._overflowGuardContainer.appendChild(this._overlayWidgets.getDomNode()),this._overflowGuardContainer.appendChild(m.getDomNode()),this._overflowGuardContainer.appendChild(p.domNode),this.domNode.appendChild(this._overflowGuardContainer),r?(r.appendChild(this._contentWidgets.overflowingContentWidgetsDomNode.domNode),r.appendChild(this._overlayWidgets.overflowingOverlayWidgetsDomNode.domNode)):(this.domNode.appendChild(this._contentWidgets.overflowingContentWidgetsDomNode),this.domNode.appendChild(this._overlayWidgets.overflowingOverlayWidgetsDomNode)),this._applyLayout(),this._pointerHandler=this._register(new we(this._context,a,this._createPointerHandlerHelper()))}_computeGlyphMarginLanes(){const e=this._context.viewModel.model,t=this._context.viewModel.glyphLanes;let i=[],s=0;i=i.concat(e.getAllMarginDecorations().map((e=>{const t=e.options.glyphMargin?.position??_t.ZS.Center;return s=Math.max(s,e.range.endLineNumber),{range:e.range,lane:t,persist:e.options.glyphMargin?.persistLane}}))),i=i.concat(this._glyphMarginWidgets.getWidgets().map((t=>{const i=e.validateRange(t.preference.range);return s=Math.max(s,i.endLineNumber),{range:i,lane:t.preference.lane}}))),i.sort(((e,t)=>q.Q.compareRangesUsingStarts(e.range,t.range))),t.reset(s);for(const n of i)t.push(n.lane,n.range,n.persist);return t}_createPointerHandlerHelper(){return{viewDomNode:this.domNode.domNode,linesContentDomNode:this._linesContent.domNode,viewLinesDomNode:this._viewLines.getDomNode().domNode,focusTextArea:()=>{this.focus()},dispatchTextAreaEvent:e=>{this._textAreaHandler.textArea.domNode.dispatchEvent(e)},getLastRenderData:()=>{const e=this._viewCursors.getLastRenderData()||[],t=this._textAreaHandler.getLastRenderData();return new ee(e,t)},renderNow:()=>{this.render(!0,!1)},shouldSuppressMouseDownOnViewZone:e=>this._viewZones.shouldSuppressMouseDownOnViewZone(e),shouldSuppressMouseDownOnWidget:e=>this._contentWidgets.shouldSuppressMouseDownOnWidget(e),getPositionFromDOMInfo:(e,t)=>(this._flushAccumulatedAndRenderNow(),this._viewLines.getPositionFromDOMInfo(e,t)),visibleRangeForPosition:(e,t)=>(this._flushAccumulatedAndRenderNow(),this._viewLines.visibleRangeForPosition(new Y.y(e,t))),getLineWidth:e=>(this._flushAccumulatedAndRenderNow(),this._viewLines.getLineWidth(e))}}_createTextAreaHandlerHelper(){return{visibleRangeForPosition:e=>(this._flushAccumulatedAndRenderNow(),this._viewLines.visibleRangeForPosition(e))}}_applyLayout(){const e=this._context.configuration.options.get(146);this.domNode.setWidth(e.width),this.domNode.setHeight(e.height),this._overflowGuardContainer.setWidth(e.width),this._overflowGuardContainer.setHeight(e.height),this._linesContent.setWidth(16777216),this._linesContent.setHeight(16777216)}_getEditorClassName(){const e=this._textAreaHandler.isFocused()?" focused":"";return this._context.configuration.options.get(143)+" "+(0,ke.Pz)(this._context.theme.type)+e}handleEvents(e){super.handleEvents(e),this._scheduleRender()}onConfigurationChanged(e){return this.domNode.setClassName(this._getEditorClassName()),this._applyLayout(),!1}onCursorStateChanged(e){return this._selections=e.selections,!1}onDecorationsChanged(e){return e.affectsGlyphMargin&&(this._shouldRecomputeGlyphMarginLanes=!0),!1}onFocusChanged(e){return this.domNode.setClassName(this._getEditorClassName()),!1}onThemeChanged(e){return this._context.theme.update(e.theme),this.domNode.setClassName(this._getEditorClassName()),!1}dispose(){null!==this._renderAnimationFrame&&(this._renderAnimationFrame.dispose(),this._renderAnimationFrame=null),this._contentWidgets.overflowingContentWidgetsDomNode.domNode.remove(),this._context.removeEventHandler(this),this._viewLines.dispose();for(const e of this._viewParts)e.dispose();super.dispose()}_scheduleRender(){if(this._store.isDisposed)throw new c.D7;if(null===this._renderAnimationFrame){const e=this._createCoordinatedRendering();this._renderAnimationFrame=Ui.INSTANCE.scheduleCoordinatedRendering({window:l.zk(this.domNode?.domNode),prepareRenderText:()=>{if(this._store.isDisposed)throw new c.D7;try{return e.prepareRenderText()}finally{this._renderAnimationFrame=null}},renderText:()=>{if(this._store.isDisposed)throw new c.D7;return e.renderText()},prepareRender:(t,i)=>{if(this._store.isDisposed)throw new c.D7;return e.prepareRender(t,i)},render:(t,i)=>{if(this._store.isDisposed)throw new c.D7;return e.render(t,i)}})}}_flushAccumulatedAndRenderNow(){const e=this._createCoordinatedRendering();Fi((()=>e.prepareRenderText()));const t=Fi((()=>e.renderText()));if(t){const[i,s]=t;Fi((()=>e.prepareRender(i,s))),Fi((()=>e.render(i,s)))}}_getViewPartsToRender(){const e=[];let t=0;for(const i of this._viewParts)i.shouldRender()&&(e[t++]=i);return e}_createCoordinatedRendering(){return{prepareRenderText:()=>{if(this._shouldRecomputeGlyphMarginLanes){this._shouldRecomputeGlyphMarginLanes=!1;const e=this._computeGlyphMarginLanes();this._context.configuration.setGlyphMarginDecorationLaneCount(e.requiredLanes)}B.p.onRenderStart()},renderText:()=>{if(!this.domNode.domNode.isConnected)return null;let e=this._getViewPartsToRender();if(!this._viewLines.shouldRender()&&0===e.length)return null;const t=this._context.viewLayout.getLinesViewportData();this._context.viewModel.setViewport(t.startLineNumber,t.endLineNumber,t.centeredLineNumber);const i=new Ni(this._selections,t,this._context.viewLayout.getWhitespaceViewportData(),this._context.viewModel);return this._contentWidgets.shouldRender()&&this._contentWidgets.onBeforeRender(i),this._viewLines.shouldRender()&&(this._viewLines.renderText(i),this._viewLines.onDidRender(),e=this._getViewPartsToRender()),[e,new je.eh(this._context.viewLayout,i,this._viewLines)]},prepareRender:(e,t)=>{for(const i of e)i.prepareRender(t)},render:(e,t)=>{for(const i of e)i.render(t),i.onDidRender()}}}delegateVerticalScrollbarPointerDown(e){this._scrollbar.delegateVerticalScrollbarPointerDown(e)}delegateScrollFromMouseWheelEvent(e){this._scrollbar.delegateScrollFromMouseWheelEvent(e)}restoreState(e){this._context.viewModel.viewLayout.setScrollPosition({scrollTop:e.scrollTop,scrollLeft:e.scrollLeft},1),this._context.viewModel.visibleLinesStabilized()}getOffsetForColumn(e,t){const i=this._context.viewModel.model.validatePosition({lineNumber:e,column:t}),s=this._context.viewModel.coordinatesConverter.convertModelPositionToViewPosition(i);this._flushAccumulatedAndRenderNow();const n=this._viewLines.visibleRangeForPosition(new Y.y(s.lineNumber,s.column));return n?n.left:-1}getTargetAtClientPoint(e,t){const i=this._pointerHandler.getTargetAtClientPoint(e,t);return i?st.convertViewToModelMouseTarget(i,this._context.viewModel.coordinatesConverter):null}createOverviewRuler(e){return new pi(this._context,e)}change(e){this._viewZones.changeViewZones(e),this._scheduleRender()}render(e,t){if(t){this._viewLines.forceShouldRender();for(const e of this._viewParts)e.forceShouldRender()}e?this._flushAccumulatedAndRenderNow():this._scheduleRender()}writeScreenReaderContent(e){this._textAreaHandler.writeScreenReaderContent(e)}focus(){this._textAreaHandler.focusTextArea()}isFocused(){return this._textAreaHandler.isFocused()}setAriaOptions(e){this._textAreaHandler.setAriaOptions(e)}addContentWidget(e){this._contentWidgets.addWidget(e.widget),this.layoutContentWidget(e),this._scheduleRender()}layoutContentWidget(e){this._contentWidgets.setWidgetPosition(e.widget,e.position?.position??null,e.position?.secondaryPosition??null,e.position?.preference??null,e.position?.positionAffinity??null),this._scheduleRender()}removeContentWidget(e){this._contentWidgets.removeWidget(e.widget),this._scheduleRender()}addOverlayWidget(e){this._overlayWidgets.addWidget(e.widget),this.layoutOverlayWidget(e),this._scheduleRender()}layoutOverlayWidget(e){this._overlayWidgets.setWidgetPosition(e.widget,e.position)&&this._scheduleRender()}removeOverlayWidget(e){this._overlayWidgets.removeWidget(e.widget),this._scheduleRender()}addGlyphMarginWidget(e){this._glyphMarginWidgets.addWidget(e.widget),this._shouldRecomputeGlyphMarginLanes=!0,this._scheduleRender()}layoutGlyphMarginWidget(e){const t=e.position;this._glyphMarginWidgets.setWidgetPosition(e.widget,t)&&(this._shouldRecomputeGlyphMarginLanes=!0,this._scheduleRender())}removeGlyphMarginWidget(e){this._glyphMarginWidgets.removeWidget(e.widget),this._shouldRecomputeGlyphMarginLanes=!0,this._scheduleRender()}};function Fi(e){try{return e()}catch(t){return(0,c.dz)(t),null}}Pi=Di([Mi(6,He._Y)],Pi);class Ui{static{this.INSTANCE=new Ui}constructor(){this._coordinatedRenderings=[],this._animationFrameRunners=new Map}scheduleCoordinatedRendering(e){return this._coordinatedRenderings.push(e),this._scheduleRender(e.window),{dispose:()=>{const t=this._coordinatedRenderings.indexOf(e);if(-1!==t&&(this._coordinatedRenderings.splice(t,1),0===this._coordinatedRenderings.length)){for(const[e,t]of this._animationFrameRunners)t.dispose();this._animationFrameRunners.clear()}}}}_scheduleRender(e){if(!this._animationFrameRunners.has(e)){const t=()=>{this._animationFrameRunners.delete(e),this._onRenderScheduled()};this._animationFrameRunners.set(e,l.Oq(e,t,100))}}_onRenderScheduled(){const e=this._coordinatedRenderings.slice(0);this._coordinatedRenderings=[];for(const i of e)Fi((()=>i.prepareRenderText()));const t=[];for(let i=0,s=e.length;is.renderText()))}for(let i=0,s=e.length;is.prepareRender(r,o)))}for(let i=0,s=e.length;is.render(r,o)))}}}var Hi=i(66782);class Bi{constructor(e,t,i,s,n){this.injectionOffsets=e,this.injectionOptions=t,this.breakOffsets=i,this.breakOffsetsVisibleColumn=s,this.wrappedTextIndentLength=n}getOutputLineCount(){return this.breakOffsets.length}getMinOutputOffset(e){return e>0?this.wrappedTextIndentLength:0}getLineLength(e){const t=e>0?this.breakOffsets[e-1]:0;let i=this.breakOffsets[e]-t;return e>0&&(i+=this.wrappedTextIndentLength),i}getMaxOutputOffset(e){return this.getLineLength(e)}translateToInputOffset(e,t){e>0&&(t=Math.max(0,t-this.wrappedTextIndentLength));let i=0===e?t:this.breakOffsets[e-1]+t;if(null!==this.injectionOffsets)for(let s=0;sthis.injectionOffsets[s];s++)i0?this.breakOffsets[n-1]:0,0===t)if(e<=r)s=n-1;else{if(!(e>o))break;i=n+1}else if(e=o))break;i=n+1}}let o=e-r;return n>0&&(o+=this.wrappedTextIndentLength),new zi(n,o)}normalizeOutputPosition(e,t,i){if(null!==this.injectionOffsets){const s=this.outputPositionToOffsetInInputWithInjections(e,t),n=this.normalizeOffsetInInputWithInjectionsAroundInjections(s,i);if(n!==s)return this.offsetInInputWithInjectionsToOutputPosition(n,i)}if(0===i){if(e>0&&t===this.getMinOutputOffset(e))return new zi(e-1,this.getMaxOutputOffset(e-1))}else if(1===i){if(e0&&(t=Math.max(0,t-this.wrappedTextIndentLength));return(e>0?this.breakOffsets[e-1]:0)+t}normalizeOffsetInInputWithInjectionsAroundInjections(e,t){const i=this.getInjectedTextAtOffset(e);if(!i)return e;if(2===t){if(e===i.offsetInInputWithInjections+i.length&&Wi(this.injectionOptions[i.injectedTextIndex].cursorStops))return i.offsetInInputWithInjections+i.length;{let e=i.offsetInInputWithInjections;if(Vi(this.injectionOptions[i.injectedTextIndex].cursorStops))return e;let t=i.injectedTextIndex-1;for(;t>=0&&this.injectionOffsets[t]===this.injectionOffsets[i.injectedTextIndex]&&!Wi(this.injectionOptions[t].cursorStops)&&(e-=this.injectionOptions[t].content.length,!Vi(this.injectionOptions[t].cursorStops));)t--;return e}}if(1===t||4===t){let e=i.offsetInInputWithInjections+i.length,t=i.injectedTextIndex;for(;t+1=0&&this.injectionOffsets[t-1]===this.injectionOffsets[t];)e-=this.injectionOptions[t-1].content.length,t--;return e}(0,Hi.xb)(t)}getInjectedText(e,t){const i=this.outputPositionToOffsetInInputWithInjections(e,t),s=this.getInjectedTextAtOffset(i);return s?{options:this.injectionOptions[s.injectedTextIndex]}:null}getInjectedTextAtOffset(e){const t=this.injectionOffsets,i=this.injectionOptions;if(null!==t){let s=0;for(let n=0;ne)break;if(e<=a)return{injectedTextIndex:n,offsetInInputWithInjections:o,length:r};s+=r}}}}function Wi(e){return null===e||void 0===e||(e===_t.VW.Right||e===_t.VW.Both)}function Vi(e){return null===e||void 0===e||(e===_t.VW.Left||e===_t.VW.Both)}class zi{constructor(e,t){this.outputLineIndex=e,this.outputOffset=t}toString(){return`${this.outputLineIndex}:${this.outputOffset}`}toPosition(e){return new Y.y(e+this.outputLineIndex,this.outputOffset+1)}}var Gi=i(64727);const ji=(0,qe.H)("domLineBreaksComputer",{createHTML:e=>e});class Ki{static create(e){return new Ki(new WeakRef(e))}constructor(e){this.targetWindow=e}createLineBreaksComputer(e,t,i,s,n){const r=[],o=[];return{addRequest:(e,t,i)=>{r.push(e),o.push(t)},finalize:()=>function(e,t,i,s,n,r,o,a){function l(e){const i=a[e];if(i){const s=Gi.uK.applyInjectedText(t[e],i),n=i.map((e=>e.options)),r=i.map((e=>e.column-1));return new Bi(r,n,[s.length],[],0)}return null}if(-1===n){const e=[];for(let i=0,s=t.length;ic?(n=0,o=0):l=c-t}const h=e.substr(n),d=Yi(h,o,s,l,m,u);f[g]=n,_[g]=o,v[g]=h,C[g]=d[0],b[g]=d[1]}const E=m.build(),S=ji?.createHTML(E)??E;p.innerHTML=S,p.style.position="absolute",p.style.top="10000","keepAll"===o?(p.style.wordBreak="keep-all",p.style.overflowWrap="anywhere"):(p.style.wordBreak="inherit",p.style.overflowWrap="break-word");e.document.body.appendChild(p);const y=document.createRange(),w=Array.prototype.slice.call(p.children,0),L=[];for(let g=0;ge.options)),o=c.map((e=>e.column-1))):(r=null,o=null),L[g]=new Bi(o,r,e,n,i)}return p.remove(),L}((0,Rt.eU)(this.targetWindow.deref()),r,e,t,i,s,n,o)}}}function Yi(e,t,i,s,n,r){if(0!==r){const e=String(r);n.appendString('
    ');const o=e.length;let a=t,l=0;const c=[],h=[];let d=0");for(let u=0;u"),c[u]=l,h[u]=a;const t=d;d=u+1"),c[e.length]=l,h[e.length]=a,n.appendString("
    "),[c,h]}function qi(e,t,i,s){if(i.length<=1)return null;const n=Array.prototype.slice.call(t.children,0),r=[];try{$i(e,n,s,0,null,i.length-1,null,r)}catch(o){return console.log(o),null}return 0===r.length?null:(r.push(i.length),r)}function $i(e,t,i,s,n,r,o,a){if(s===r)return;if(n=n||Qi(e,t,i[s],i[s+1]),o=o||Qi(e,t,i[r],i[r+1]),Math.abs(n[0].top-o[0].top)<=.1)return;if(s+1===r)return void a.push(r);const l=s+(r-s)/2|0,c=Qi(e,t,i[l],i[l+1]);$i(e,t,i,s,n,l,c,a),$i(e,t,i,l,c,r,o,a)}function Qi(e,t,i,s){return e.setStart(t[i/16384|0].firstChild,i%16384),e.setEnd(t[s/16384|0].firstChild,s%16384),e.getClientRects()}class Xi extends d.jG{constructor(){super(),this._editor=null,this._instantiationService=null,this._instances=this._register(new d.$w),this._pending=new Map,this._finishedInstantiation=[],this._finishedInstantiation[0]=!1,this._finishedInstantiation[1]=!1,this._finishedInstantiation[2]=!1,this._finishedInstantiation[3]=!1}initialize(e,t,i){this._editor=e,this._instantiationService=i;for(const s of t)this._pending.has(s.id)?(0,c.dz)(new Error(`Cannot have two contributions with the same id ${s.id}`)):this._pending.set(s.id,s);this._instantiateSome(0),this._register((0,l.U3)((0,l.zk)(this._editor.getDomNode()),(()=>{this._instantiateSome(1)}))),this._register((0,l.U3)((0,l.zk)(this._editor.getDomNode()),(()=>{this._instantiateSome(2)}))),this._register((0,l.U3)((0,l.zk)(this._editor.getDomNode()),(()=>{this._instantiateSome(3)}),5e3))}saveViewState(){const e={};for(const[t,i]of this._instances)"function"===typeof i.saveViewState&&(e[t]=i.saveViewState());return e}restoreViewState(e){for(const[t,i]of this._instances)"function"===typeof i.restoreViewState&&i.restoreViewState(e[t])}get(e){return this._instantiateById(e),this._instances.get(e)||null}onBeforeInteractionEvent(){this._instantiateSome(2)}onAfterModelAttached(){return(0,l.U3)((0,l.zk)(this._editor?.getDomNode()),(()=>{this._instantiateSome(1)}),50)}_instantiateSome(e){if(this._finishedInstantiation[e])return;this._finishedInstantiation[e]=!0;const t=this._findPendingContributionsByInstantiation(e);for(const i of t)this._instantiateById(i.id)}_findPendingContributionsByInstantiation(e){const t=[];for(const[,i]of this._pending)i.instantiation===e&&t.push(i);return t}_instantiateById(e){const t=this._pending.get(e);if(t){if(this._pending.delete(e),!this._instantiationService||!this._editor)throw new Error("Cannot instantiate contributions before being initialized!");try{const e=this._instantiationService.createInstance(t.ctor,this._editor);this._instances.set(t.id,e),"function"===typeof e.restoreViewState&&0!==t.instantiation&&console.warn(`Editor contribution '${t.id}' should be eager instantiated because it uses saveViewState / restoreViewState.`)}catch(i){(0,c.dz)(i)}}}}var Zi=i(97681),Ji=i(29611),es=i(23452),ts=i(60002),is=i(17469),ss=i(87289),ns=i(56942),rs=i(60534);class os{static create(e){return new os(e.get(135),e.get(134))}constructor(e,t){this.classifier=new as(e,t)}createLineBreaksComputer(e,t,i,s,n){const r=[],o=[],a=[];return{addRequest:(e,t,i)=>{r.push(e),o.push(t),a.push(i)},finalize:()=>{const l=e.typicalFullwidthCharacterWidth/e.typicalHalfwidthCharacterWidth,c=[];for(let e=0,h=r.length;e=0&&e<256?this._asciiMap[e]:e>=12352&&e<=12543||e>=13312&&e<=19903||e>=19968&&e<=40959?3:this._map.get(e)||this._defaultValue}}let ls=[],cs=[];function hs(e,t,i,s,n,r,o,a){if(-1===n)return null;const l=i.length;if(l<=1)return null;const c="keepAll"===a,h=t.breakOffsets,d=t.breakOffsetsVisibleColumn,u=ms(i,s,n,r,o),g=n-u,p=ls,m=cs;let f=0,_=0,v=0,C=n;const b=h.length;let E=0;if(E>=0){let e=Math.abs(d[E]-C);for(;E+1=e)break;e=t,E++}}for(;Et&&(t=_,n=v);let o=0,a=0,u=0,S=0;if(n<=C){let v=n,b=0===t?0:i.charCodeAt(t-1),E=0===t?0:e.get(b),y=!0;for(let n=t;n_&&ps(b,E,l,h,c)&&(o=t,a=v),v+=d,v>C){t>_?(u=t,S=v-d):(u=n+1,S=v),v-a>g&&(o=0),y=!1;break}b=l,E=h}if(y){f>0&&(p[f]=h[h.length-1],m[f]=d[h.length-1],f++);break}}if(0===o){let l=n,h=i.charCodeAt(t),d=e.get(h),p=!1;for(let s=t-1;s>=_;s--){const t=s+1,n=i.charCodeAt(s);if(9===n){p=!0;break}let m,f;if(Re.LJ(n)?(s--,m=0,f=2):(m=e.get(n),f=Re.ne(n)?r:1),l<=C){if(0===u&&(u=t,S=l),l<=C-g)break;if(ps(n,m,h,d,c)){o=t,a=l;break}}l-=f,h=n,d=m}if(0!==o){const e=g-(S-a);if(e<=s){const t=i.charCodeAt(u);let n;n=Re.pc(t)?2:us(t,S,s,r),e-n<0&&(o=0)}}if(p){E--;continue}}if(0===o&&(o=u,a=S),o<=_){const e=i.charCodeAt(_);Re.pc(e)?(o=_+2,a=v+2):(o=_+1,a=v+us(e,v,s,r))}for(_=o,p[f]=o,v=a,m[f]=a,f++,C=a+g;E<0||E=y)break;y=e,E++}}return 0===f?null:(p.length=f,m.length=f,ls=t.breakOffsets,cs=t.breakOffsetsVisibleColumn,t.breakOffsets=p,t.breakOffsetsVisibleColumn=m,t.wrappedTextIndentLength=u,t)}function ds(e,t,i,s,n,r,o,a){const l=Gi.uK.applyInjectedText(t,i);let c,h;if(i&&i.length>0?(c=i.map((e=>e.options)),h=i.map((e=>e.column-1))):(c=null,h=null),-1===n)return c?new Bi(h,c,[l.length],[],0):null;const d=l.length;if(d<=1)return c?new Bi(h,c,[l.length],[],0):null;const u="keepAll"===a,g=ms(l,s,n,r,o),p=n-g,m=[],f=[];let _=0,v=0,C=0,b=n,E=l.charCodeAt(0),S=e.get(E),y=us(E,0,s,r),w=1;Re.pc(E)&&(y+=1,E=l.charCodeAt(1),S=e.get(E),w++);for(let L=w;Lb&&((0===v||y-C>p)&&(v=t,C=y-o),m[_]=v,f[_]=C,_++,b=C+p,v=0),E=i,S=n}return 0!==_||i&&0!==i.length?(m[_]=d,f[_]=y,new Bi(h,c,m,f,g)):null}function us(e,t,i,s){return 9===e?i-t%i:Re.ne(e)||e<32?s:1}function gs(e,t){return t-e%t}function ps(e,t,i,s,n){return 32!==i&&(2===t&&2!==s||1!==t&&1===s||!n&&3===t&&2!==s||!n&&3===s&&1!==t)}function ms(e,t,i,s,n){let r=0;if(0!==n){const o=Re.HG(e);if(-1!==o){for(let i=0;ii&&(r=0)}}return r}var fs=i(46041),_s=i(32799);class vs{constructor(e){this._selTrackedRange=null,this._trackSelection=!0,this._setState(e,new _s.mG(new q.Q(1,1,1,1),0,0,new Y.y(1,1),0),new _s.mG(new q.Q(1,1,1,1),0,0,new Y.y(1,1),0))}dispose(e){this._removeTrackedRange(e)}startTrackingSelection(e){this._trackSelection=!0,this._updateTrackedRange(e)}stopTrackingSelection(e){this._trackSelection=!1,this._removeTrackedRange(e)}_updateTrackedRange(e){this._trackSelection&&(this._selTrackedRange=e.model._setTrackedRange(this._selTrackedRange,this.modelState.selection,0))}_removeTrackedRange(e){this._selTrackedRange=e.model._setTrackedRange(this._selTrackedRange,null,0)}asCursorState(){return new _s.MF(this.modelState,this.viewState)}readSelectionFromMarkers(e){const t=e.model._getTrackedRange(this._selTrackedRange);return this.modelState.selection.isEmpty()&&!t.isEmpty()?pe.L.fromRange(t.collapseToEnd(),this.modelState.selection.getDirection()):pe.L.fromRange(t,this.modelState.selection.getDirection())}ensureValidState(e){this._setState(e,this.modelState,this.viewState)}setState(e,t,i){this._setState(e,t,i)}static _validatePositionWithCache(e,t,i,s){return t.equals(i)?s:e.normalizePosition(t,2)}static _validateViewState(e,t){const i=t.position,s=t.selectionStart.getStartPosition(),n=t.selectionStart.getEndPosition(),r=e.normalizePosition(i,2),o=this._validatePositionWithCache(e,s,i,r),a=this._validatePositionWithCache(e,n,s,o);return i.equals(r)&&s.equals(o)&&n.equals(a)?t:new _s.mG(q.Q.fromPositions(o,a),t.selectionStartKind,t.selectionStartLeftoverVisibleColumns+s.column-o.column,r,t.leftoverVisibleColumns+i.column-r.column)}_setState(e,t,i){if(i&&(i=vs._validateViewState(e.viewModel,i)),t){const i=e.model.validateRange(t.selectionStart),s=t.selectionStart.equalsRange(i)?t.selectionStartLeftoverVisibleColumns:0,n=e.model.validatePosition(t.position),r=t.position.equals(n)?t.leftoverVisibleColumns:0;t=new _s.mG(i,t.selectionStartKind,s,n,r)}else{if(!i)return;const s=e.model.validateRange(e.coordinatesConverter.convertViewRangeToModelRange(i.selectionStart)),n=e.model.validatePosition(e.coordinatesConverter.convertViewPositionToModelPosition(i.position));t=new _s.mG(s,i.selectionStartKind,i.selectionStartLeftoverVisibleColumns,n,i.leftoverVisibleColumns)}if(i){const s=e.coordinatesConverter.validateViewRange(i.selectionStart,t.selectionStart),n=e.coordinatesConverter.validateViewPosition(i.position,t.position);i=new _s.mG(s,t.selectionStartKind,t.selectionStartLeftoverVisibleColumns,n,t.leftoverVisibleColumns)}else{const s=e.coordinatesConverter.convertModelPositionToViewPosition(new Y.y(t.selectionStart.startLineNumber,t.selectionStart.startColumn)),n=e.coordinatesConverter.convertModelPositionToViewPosition(new Y.y(t.selectionStart.endLineNumber,t.selectionStart.endColumn)),r=new q.Q(s.lineNumber,s.column,n.lineNumber,n.column),o=e.coordinatesConverter.convertModelPositionToViewPosition(t.position);i=new _s.mG(r,t.selectionStartKind,t.selectionStartLeftoverVisibleColumns,o,t.leftoverVisibleColumns)}this.modelState=t,this.viewState=i,this._updateTrackedRange(e)}}class Cs{constructor(e){this.context=e,this.cursors=[new vs(e)],this.lastAddedCursorIndex=0}dispose(){for(const e of this.cursors)e.dispose(this.context)}startTrackingSelections(){for(const e of this.cursors)e.startTrackingSelection(this.context)}stopTrackingSelections(){for(const e of this.cursors)e.stopTrackingSelection(this.context)}updateContext(e){this.context=e}ensureValidState(){for(const e of this.cursors)e.ensureValidState(this.context)}readSelectionFromMarkers(){return this.cursors.map((e=>e.readSelectionFromMarkers(this.context)))}getAll(){return this.cursors.map((e=>e.asCursorState()))}getViewPositions(){return this.cursors.map((e=>e.viewState.position))}getTopMostViewPosition(){return(0,fs.kh)(this.cursors,(0,m.VE)((e=>e.viewState.position),Y.y.compare)).viewState.position}getBottomMostViewPosition(){return(0,fs.ot)(this.cursors,(0,m.VE)((e=>e.viewState.position),Y.y.compare)).viewState.position}getSelections(){return this.cursors.map((e=>e.modelState.selection))}getViewSelections(){return this.cursors.map((e=>e.viewState.selection))}setSelections(e){this.setStates(_s.MF.fromModelSelections(e))}getPrimaryCursor(){return this.cursors[0].asCursorState()}setStates(e){null!==e&&(this.cursors[0].setState(this.context,e[0].modelState,e[0].viewState),this._setSecondaryStates(e.slice(1)))}_setSecondaryStates(e){const t=this.cursors.length-1,i=e.length;if(ti){const e=t-i;for(let t=0;t=e+1&&this.lastAddedCursorIndex--,this.cursors[e+1].dispose(this.context),this.cursors.splice(e+1,1)}normalize(){if(1===this.cursors.length)return;const e=this.cursors.slice(0),t=[];for(let i=0,s=e.length;ie.selection),q.Q.compareRangesUsingStarts));for(let i=0;ia&&e.index--;e.splice(a,1),t.splice(o,1),this._removeSecondaryCursor(a-1),i--}}}}class bs{constructor(e,t,i,s){this._cursorContextBrand=void 0,this.model=e,this.viewModel=t,this.coordinatesConverter=i,this.cursorConfig=s}}var Es=i(1226),Ss=i(49265),ys=i(26685);class ws{constructor(){this.type=0}}class Ls{constructor(){this.type=1}}class Rs{constructor(e){this.type=2,this._source=e}hasChanged(e){return this._source.hasChanged(e)}}class Ts{constructor(e,t,i){this.selections=e,this.modelSelections=t,this.reason=i,this.type=3}}class xs{constructor(e){this.type=4,e?(this.affectsMinimap=e.affectsMinimap,this.affectsOverviewRuler=e.affectsOverviewRuler,this.affectsGlyphMargin=e.affectsGlyphMargin,this.affectsLineNumber=e.affectsLineNumber):(this.affectsMinimap=!0,this.affectsOverviewRuler=!0,this.affectsGlyphMargin=!0,this.affectsLineNumber=!0)}}class ks{constructor(){this.type=5}}class As{constructor(e){this.type=6,this.isFocused=e}}class Ns{constructor(){this.type=7}}class Is{constructor(){this.type=8}}class Os{constructor(e,t){this.fromLineNumber=e,this.count=t,this.type=9}}class Ds{constructor(e,t){this.type=10,this.fromLineNumber=e,this.toLineNumber=t}}class Ms{constructor(e,t){this.type=11,this.fromLineNumber=e,this.toLineNumber=t}}class Ps{constructor(e,t,i,s,n,r,o){this.source=e,this.minimalReveal=t,this.range=i,this.selections=s,this.verticalType=n,this.revealHorizontal=r,this.scrollType=o,this.type=12}}class Fs{constructor(e){this.type=13,this.scrollWidth=e.scrollWidth,this.scrollLeft=e.scrollLeft,this.scrollHeight=e.scrollHeight,this.scrollTop=e.scrollTop,this.scrollWidthChanged=e.scrollWidthChanged,this.scrollLeftChanged=e.scrollLeftChanged,this.scrollHeightChanged=e.scrollHeightChanged,this.scrollTopChanged=e.scrollTopChanged}}class Us{constructor(e){this.theme=e,this.type=14}}class Hs{constructor(e){this.type=15,this.ranges=e}}class Bs{constructor(){this.type=16}}class Ws{constructor(){this.type=17}}class Vs extends d.jG{constructor(){super(),this._onEvent=this._register(new h.vl),this.onEvent=this._onEvent.event,this._eventHandlers=[],this._viewEventQueue=null,this._isConsumingViewEventQueue=!1,this._collector=null,this._collectorCnt=0,this._outgoingEvents=[]}emitOutgoingEvent(e){this._addOutgoingEvent(e),this._emitOutgoingEvents()}_addOutgoingEvent(e){for(let t=0,i=this._outgoingEvents.length;t0;){if(this._collector||this._isConsumingViewEventQueue)return;const e=this._outgoingEvents.shift();e.isNoOp()||this._onEvent.fire(e)}}addViewEventHandler(e){for(let t=0,i=this._eventHandlers.length;t0&&this._emitMany(t)}this._emitOutgoingEvents()}emitSingleViewEvent(e){try{this.beginEmitViewEvents().emitViewEvent(e)}finally{this.endEmitViewEvents()}}_emitMany(e){this._viewEventQueue?this._viewEventQueue=this._viewEventQueue.concat(e):this._viewEventQueue=e,this._isConsumingViewEventQueue||this._consumeViewEventQueue()}_consumeViewEventQueue(){try{this._isConsumingViewEventQueue=!0,this._doConsumeQueue()}finally{this._isConsumingViewEventQueue=!1}}_doConsumeQueue(){for(;this._viewEventQueue;){const e=this._viewEventQueue;this._viewEventQueue=null;const t=this._eventHandlers.slice(0);for(const i of t)i.handleEvents(e)}}}class zs{constructor(){this.viewEvents=[],this.outgoingEvents=[]}emitViewEvent(e){this.viewEvents.push(e)}emitOutgoingEvent(e){this.outgoingEvents.push(e)}}class Gs{constructor(e,t,i,s){this.kind=0,this._oldContentWidth=e,this._oldContentHeight=t,this.contentWidth=i,this.contentHeight=s,this.contentWidthChanged=this._oldContentWidth!==this.contentWidth,this.contentHeightChanged=this._oldContentHeight!==this.contentHeight}isNoOp(){return!this.contentWidthChanged&&!this.contentHeightChanged}attemptToMerge(e){return e.kind!==this.kind?null:new Gs(this._oldContentWidth,this._oldContentHeight,e.contentWidth,e.contentHeight)}}class js{constructor(e,t){this.kind=1,this.oldHasFocus=e,this.hasFocus=t}isNoOp(){return this.oldHasFocus===this.hasFocus}attemptToMerge(e){return e.kind!==this.kind?null:new js(this.oldHasFocus,e.hasFocus)}}class Ks{constructor(e,t,i,s,n,r,o,a){this.kind=2,this._oldScrollWidth=e,this._oldScrollLeft=t,this._oldScrollHeight=i,this._oldScrollTop=s,this.scrollWidth=n,this.scrollLeft=r,this.scrollHeight=o,this.scrollTop=a,this.scrollWidthChanged=this._oldScrollWidth!==this.scrollWidth,this.scrollLeftChanged=this._oldScrollLeft!==this.scrollLeft,this.scrollHeightChanged=this._oldScrollHeight!==this.scrollHeight,this.scrollTopChanged=this._oldScrollTop!==this.scrollTop}isNoOp(){return!this.scrollWidthChanged&&!this.scrollLeftChanged&&!this.scrollHeightChanged&&!this.scrollTopChanged}attemptToMerge(e){return e.kind!==this.kind?null:new Ks(this._oldScrollWidth,this._oldScrollLeft,this._oldScrollHeight,this._oldScrollTop,e.scrollWidth,e.scrollLeft,e.scrollHeight,e.scrollTop)}}class Ys{constructor(){this.kind=3}isNoOp(){return!1}attemptToMerge(e){return e.kind!==this.kind?null:this}}class qs{constructor(){this.kind=4}isNoOp(){return!1}attemptToMerge(e){return e.kind!==this.kind?null:this}}class $s{constructor(e,t,i,s,n,r,o){this.kind=6,this.oldSelections=e,this.selections=t,this.oldModelVersionId=i,this.modelVersionId=s,this.source=n,this.reason=r,this.reachedMaxCursorCount=o}static _selectionsAreEqual(e,t){if(!e&&!t)return!0;if(!e||!t)return!1;const i=e.length;if(i!==t.length)return!1;for(let s=0;s0){const e=this._cursors.getSelections();for(let t=0;tr&&(s=s.slice(0,r),n=!0);const o=rn.from(this._model,this);return this._cursors.setStates(s),this._cursors.normalize(),this._columnSelectData=null,this._validateAutoClosedActions(),this._emitStateChangedIfNecessary(e,t,i,o,n)}setCursorColumnSelectData(e){this._columnSelectData=e}revealAll(e,t,i,s,n,r){const o=this._cursors.getViewPositions();let a=null,l=null;o.length>1?l=this._cursors.getViewSelections():a=q.Q.fromPositions(o[0],o[0]),e.emitViewEvent(new Ps(t,i,a,l,s,n,r))}revealPrimary(e,t,i,s,n,r){const o=[this._cursors.getPrimaryCursor().viewState.selection];e.emitViewEvent(new Ps(t,i,null,o,s,n,r))}saveState(){const e=[],t=this._cursors.getSelections();for(let i=0,s=t.length;i0){const t=_s.MF.fromModelSelections(i.resultingSelection);this.setStates(e,"modelChange",i.isUndoing?5:i.isRedoing?6:2,t)&&this.revealAll(e,"modelChange",!1,0,!0,0)}else{const t=this._cursors.readSelectionFromMarkers();this.setStates(e,"modelChange",2,_s.MF.fromModelSelections(t))}}}getSelection(){return this._cursors.getPrimaryCursor().modelState.selection}getTopMostViewPosition(){return this._cursors.getTopMostViewPosition()}getBottomMostViewPosition(){return this._cursors.getBottomMostViewPosition()}getCursorColumnSelectData(){if(this._columnSelectData)return this._columnSelectData;const e=this._cursors.getPrimaryCursor(),t=e.viewState.selectionStart.getStartPosition(),i=e.viewState.position;return{isReal:!1,fromViewLineNumber:t.lineNumber,fromViewVisualColumn:this.context.cursorConfig.visibleColumnFromColumn(this._viewModel,t),toViewLineNumber:i.lineNumber,toViewVisualColumn:this.context.cursorConfig.visibleColumnFromColumn(this._viewModel,i)}}getSelections(){return this._cursors.getSelections()}setSelections(e,t,i,s){this.setStates(e,t,s,_s.MF.fromModelSelections(i))}getPrevEditOperationType(){return this._prevEditOperationType}setPrevEditOperationType(e){this._prevEditOperationType=e}_pushAutoClosedAction(e,t){const i=[],s=[];for(let o=0,a=e.length;o0&&this._pushAutoClosedAction(i,s),this._prevEditOperationType=e.type}e.shouldPushStackElementAfter&&this._model.pushStackElement()}_interpretCommandResult(e){e&&0!==e.length||(e=this._cursors.readSelectionFromMarkers()),this._columnSelectData=null,this._cursors.setSelections(e),this._cursors.normalize()}_emitStateChangedIfNecessary(e,t,i,s,n){const r=rn.from(this._model,this);if(r.equals(s))return!1;const o=this._cursors.getSelections(),a=this._cursors.getViewSelections();if(e.emitViewEvent(new Ts(a,o,i)),!s||s.cursorState.length!==r.cursorState.length||r.cursorState.some(((e,t)=>!e.modelState.equals(s.cursorState[t].modelState)))){const a=s?s.cursorState.map((e=>e.modelState.selection)):null,l=s?s.modelVersionId:0;e.emitOutgoingEvent(new $s(a,o,l,r.modelVersionId,t||"keyboard",i,n))}return!0}_findAutoClosingPairs(e){if(!e.length)return null;const t=[];for(let i=0,s=e.length;i=0)return null;const n=s.text.match(/([)\]}>'"`])([^)\]}>'"`]*)$/);if(!n)return null;const r=n[1],o=this.context.cursorConfig.autoClosingPairs.autoClosingPairsCloseSingleChar.get(r);if(!o||1!==o.length)return null;const a=o[0].open,l=s.text.length-n[2].length-1,c=s.text.lastIndexOf(a,l-1);if(-1===c)return null;t.push([c,l])}return t}executeEdits(e,t,i,s){let n=null;"snippet"===t&&(n=this._findAutoClosingPairs(i)),n&&(i[0]._isTracked=!0);const r=[],o=[],a=this._model.pushEditOperations(this.getSelections(),i,(e=>{if(n)for(let i=0,s=n.length;i0&&this._pushAutoClosedAction(r,o)}_executeEdit(e,t,i,s=0){if(this.context.cursorConfig.readOnly)return;const n=rn.from(this._model,this);this._cursors.stopTrackingSelections(),this._isHandling=!0;try{this._cursors.ensureValidState(),e()}catch(r){(0,c.dz)(r)}this._isHandling=!1,this._cursors.startTrackingSelections(),this._validateAutoClosedActions(),this._emitStateChangedIfNecessary(t,i,s,n,!1)&&this.revealAll(t,i,!1,0,!0,0)}getAutoClosedCharacters(){return on.getAllAutoClosedCharacters(this._autoClosedActions)}startComposition(e){this._compositionState=new cn(this._model,this.getSelections())}endComposition(e,t){const i=this._compositionState?this._compositionState.deduceOutcome(this._model,this.getSelections()):null;this._compositionState=null,this._executeEdit((()=>{"keyboard"===t&&this._executeEditOperation(Ss.T.compositionEndWithInterceptors(this._prevEditOperationType,this.context.cursorConfig,this._model,i,this.getSelections(),this.getAutoClosedCharacters()))}),e,t)}type(e,t,i){this._executeEdit((()=>{if("keyboard"===i){const e=t.length;let i=0;for(;i{this._executeEditOperation(Ss.T.compositionType(this._prevEditOperationType,this.context.cursorConfig,this._model,this.getSelections(),t,i,s,n))}),e,r);else if(0!==n){const t=this.getSelections().map((e=>{const t=e.getPosition();return new pe.L(t.lineNumber,t.column+n,t.lineNumber,t.column+n)}));this.setSelections(e,r,t,0)}}paste(e,t,i,s,n){this._executeEdit((()=>{this._executeEditOperation(Ss.T.paste(this.context.cursorConfig,this._model,this.getSelections(),t,i,s||[]))}),e,n,4)}cut(e,t){this._executeEdit((()=>{this._executeEditOperation(Es.g.cut(this.context.cursorConfig,this._model,this.getSelections()))}),e,t)}executeCommand(e,t,i){this._executeEdit((()=>{this._cursors.killSecondaryCursors(),this._executeEditOperation(new _s.vY(0,[t],{shouldPushStackElementBefore:!1,shouldPushStackElementAfter:!1}))}),e,i)}executeCommands(e,t,i){this._executeEdit((()=>{this._executeEditOperation(new _s.vY(0,t,{shouldPushStackElementBefore:!1,shouldPushStackElementAfter:!1}))}),e,i)}}class rn{static from(e,t){return new rn(e.getVersionId(),t.getCursorStates())}constructor(e,t){this.modelVersionId=e,this.cursorState=t}equals(e){if(!e)return!1;if(this.modelVersionId!==e.modelVersionId)return!1;if(this.cursorState.length!==e.cursorState.length)return!1;for(let t=0,i=this.cursorState.length;t=t.length)return!1;if(!t[i].strictContainsRange(e[i]))return!1}return!0}}class an{static executeCommands(e,t,i){const s={model:e,selectionsBefore:t,trackedRanges:[],trackedRangesDirection:[]},n=this._innerExecuteCommands(s,i);for(let r=0,o=s.trackedRanges.length;r0&&(r[0]._isTracked=!0);let o=e.model.pushEditOperations(e.selectionsBefore,r,(i=>{const s=[];for(let t=0;te.identifier.minor-t.identifier.minor,r=[];for(let o=0;o0?(s[o].sort(n),r[o]=t[o].computeCursorState(e.model,{getInverseEditOperations:()=>s[o],getTrackedSelection:t=>{const i=parseInt(t,10),s=e.model._getTrackedRange(e.trackedRanges[i]);return 0===e.trackedRangesDirection[i]?new pe.L(s.startLineNumber,s.startColumn,s.endLineNumber,s.endColumn):new pe.L(s.endLineNumber,s.endColumn,s.startLineNumber,s.startColumn)}})):r[o]=e.selectionsBefore[o];return r}));o||(o=e.selectionsBefore);const a=[];for(const l in n)n.hasOwnProperty(l)&&a.push(parseInt(l,10));a.sort(((e,t)=>t-e));for(const l of a)o.splice(l,1);return o}static _arrayIsEmpty(e){for(let t=0,i=e.length;t{q.Q.isEmpty(e)&&""===r||s.push({identifier:{major:t,minor:n++},range:e,text:r,forceMoveMarkers:o,isAutoWhitespaceEdit:i.insertsAutoWhitespace})};let o=!1;const a={addEditOperation:r,addTrackedEditOperation:(e,t,i)=>{o=!0,r(e,t,i)},trackSelection:(t,i)=>{const s=pe.L.liftSelection(t);let n;if(s.isEmpty())if("boolean"===typeof i)n=i?2:3;else{const t=e.model.getLineMaxColumn(s.startLineNumber);n=s.startColumn===t?2:3}else n=1;const r=e.trackedRanges.length,o=e.model._setTrackedRange(null,s,n);return e.trackedRanges[r]=o,e.trackedRangesDirection[r]=s.getDirection(),r.toString()}};try{i.getEditOperations(e.model,a)}catch(l){return(0,c.dz)(l),{operations:[],hadTrackedEditOperation:!1}}return{operations:s,hadTrackedEditOperation:o}}static _getLoserCursorMap(e){(e=e.slice(0)).sort(((e,t)=>-q.Q.compareRangesUsingEnds(e.range,t.range)));const t={};for(let i=1;in.identifier.major?s.identifier.major:n.identifier.major,t[r.toString()]=!0;for(let t=0;t0&&i--}}return t}}class ln{constructor(e,t,i){this.text=e,this.startSelection=t,this.endSelection=i}}class cn{static _capture(e,t){const i=[];for(const s of t){if(s.startLineNumber!==s.endLineNumber)return null;i.push(new ln(e.getLineContent(s.startLineNumber),s.startColumn-1,s.endColumn-1))}return i}constructor(e,t){this._original=cn._capture(e,t)}deduceOutcome(e,t){if(!this._original)return null;const i=cn._capture(e,t);if(!i)return null;if(this._original.length!==i.length)return null;const s=[];for(let n=0,r=this._original.length;n>>1;t===e[r].afterLineNumber?i{t=!0,e|=0,i|=0,s|=0,n|=0;const r=this._instanceId+ ++this._lastWhitespaceId;return this._pendingChanges.insert(new pn(r,e,i,s,n)),r},changeOneWhitespace:(e,i,s)=>{t=!0,i|=0,s|=0,this._pendingChanges.change({id:e,newAfterLineNumber:i,newHeight:s})},removeWhitespace:e=>{t=!0,this._pendingChanges.remove({id:e})}})}finally{this._pendingChanges.commit(this)}return t}_commitPendingChanges(e,t,i){if((e.length>0||i.length>0)&&(this._minWidth=-1),e.length+t.length+i.length<=1){for(const t of e)this._insertWhitespace(t);for(const e of t)this._changeOneWhitespace(e.id,e.newAfterLineNumber,e.newHeight);for(const e of i){const t=this._findWhitespaceIndex(e.id);-1!==t&&this._removeWhitespace(t)}return}const s=new Set;for(const a of i)s.add(a.id);const n=new Map;for(const a of t)n.set(a.id,a);const r=e=>{const t=[];for(const i of e)if(!s.has(i.id)){if(n.has(i.id)){const e=n.get(i.id);i.afterLineNumber=e.newAfterLineNumber,i.height=e.newHeight}t.push(i)}return t},o=r(this._arr).concat(r(e));o.sort(((e,t)=>e.afterLineNumber===t.afterLineNumber?e.ordinal-t.ordinal:e.afterLineNumber-t.afterLineNumber)),this._arr=o,this._prefixSumValidIndex=-1}_checkPendingChanges(){this._pendingChanges.mustCommit()&&this._pendingChanges.commit(this)}_insertWhitespace(e){const t=mn.findInsertionIndex(this._arr,e.afterLineNumber,e.ordinal);this._arr.splice(t,0,e),this._prefixSumValidIndex=Math.min(this._prefixSumValidIndex,t-1)}_findWhitespaceIndex(e){const t=this._arr;for(let i=0,s=t.length;it&&(this._arr[i].afterLineNumber-=t-e+1)}}onLinesInserted(e,t){this._checkPendingChanges(),e|=0,t|=0,this._lineCount+=t-e+1;for(let i=0,s=this._arr.length;i=t.length||t[n+1].afterLineNumber>=e)return n;i=n+1|0}else s=n-1|0}return-1}_findFirstWhitespaceAfterLineNumber(e){e|=0;const t=this._findLastWhitespaceBeforeLineNumber(e)+1;return t1?this._lineHeight*(e-1):0;return i+this.getWhitespaceAccumulatedHeightBeforeLineNumber(e-(t?1:0))+this._paddingTop}getVerticalOffsetAfterLineNumber(e,t=!1){this._checkPendingChanges(),e|=0;return this._lineHeight*e+this.getWhitespaceAccumulatedHeightBeforeLineNumber(e+(t?1:0))+this._paddingTop}getWhitespaceMinWidth(){if(this._checkPendingChanges(),-1===this._minWidth){let e=0;for(let t=0,i=this._arr.length;tthis.getLinesTotalHeight()}isInTopPadding(e){return 0!==this._paddingTop&&(this._checkPendingChanges(),e=this.getLinesTotalHeight()-this._paddingBottom}getLineNumberAtOrAfterVerticalOffset(e){if(this._checkPendingChanges(),(e|=0)<0)return 1;const t=0|this._lineCount,i=this._lineHeight;let s=1,n=t;for(;s=r+i)s=t+1;else{if(e>=r)return t;n=t}}return s>t?t:s}getLinesViewportData(e,t){this._checkPendingChanges(),e|=0,t|=0;const i=this._lineHeight,s=0|this.getLineNumberAtOrAfterVerticalOffset(e),n=0|this.getVerticalOffsetForLineNumber(s);let r=0|this._lineCount,o=0|this.getFirstWhitespaceIndexAfterLineNumber(s);const a=0|this.getWhitespacesCount();let l,c;-1===o?(o=a,c=r+1,l=0):(c=0|this.getAfterLineNumberForWhitespaceIndex(o),l=0|this.getHeightForWhitespaceIndex(o));let h=n,d=h;const u=5e5;let g=0;n>=u&&(g=Math.floor(n/u)*u,g=Math.floor(g/i)*i,d-=g);const p=[],m=e+(t-e)/2;let f=-1;for(let b=s;b<=r;b++){if(-1===f){(h<=m&&mm)&&(f=b)}for(h+=i,p[b-s]=d,d+=i;c===b;)d+=l,h+=l,o++,o>=a?c=r+1:(c=0|this.getAfterLineNumberForWhitespaceIndex(o),l=0|this.getHeightForWhitespaceIndex(o));if(h>=t){r=b;break}}-1===f&&(f=r);const _=0|this.getVerticalOffsetForLineNumber(r);let v=s,C=r;return vt&&C--,{bigNumbersDelta:g,startLineNumber:s,endLineNumber:r,relativeVerticalOffset:p,centeredLineNumber:f,completelyVisibleStartLineNumber:v,completelyVisibleEndLineNumber:C,lineHeight:this._lineHeight}}getVerticalOffsetForWhitespaceIndex(e){this._checkPendingChanges(),e|=0;const t=this.getAfterLineNumberForWhitespaceIndex(e);let i,s;return i=t>=1?this._lineHeight*t:0,s=e>0?this.getWhitespacesAccumulatedHeight(e-1):0,i+s+this._paddingTop}getWhitespaceIndexAtOrAfterVerticallOffset(e){this._checkPendingChanges(),e|=0;let t=0,i=this.getWhitespacesCount()-1;if(i<0)return-1;if(e>=this.getVerticalOffsetForWhitespaceIndex(i)+this.getHeightForWhitespaceIndex(i))return-1;for(;t=n+this.getHeightForWhitespaceIndex(s))t=s+1;else{if(e>=n)return s;i=s}}return t}getWhitespaceAtVerticalOffset(e){this._checkPendingChanges(),e|=0;const t=this.getWhitespaceIndexAtOrAfterVerticallOffset(e);if(t<0)return null;if(t>=this.getWhitespacesCount())return null;const i=this.getVerticalOffsetForWhitespaceIndex(t);if(i>e)return null;const s=this.getHeightForWhitespaceIndex(t);return{id:this.getIdForWhitespaceIndex(t),afterLineNumber:this.getAfterLineNumberForWhitespaceIndex(t),verticalOffset:i,height:s}}getWhitespaceViewportData(e,t){this._checkPendingChanges(),e|=0,t|=0;const i=this.getWhitespaceIndexAtOrAfterVerticallOffset(e),s=this.getWhitespacesCount()-1;if(i<0)return[];const n=[];for(let r=i;r<=s;r++){const e=this.getVerticalOffsetForWhitespaceIndex(r),i=this.getHeightForWhitespaceIndex(r);if(e>=t)break;n.push({id:this.getIdForWhitespaceIndex(r),afterLineNumber:this.getAfterLineNumberForWhitespaceIndex(r),verticalOffset:e,height:i})}return n}getWhitespaces(){return this._checkPendingChanges(),this._arr.slice(0)}getWhitespacesCount(){return this._checkPendingChanges(),this._arr.length}getIdForWhitespaceIndex(e){return this._checkPendingChanges(),e|=0,this._arr[e].id}getAfterLineNumberForWhitespaceIndex(e){return this._checkPendingChanges(),e|=0,this._arr[e].afterLineNumber}getHeightForWhitespaceIndex(e){return this._checkPendingChanges(),e|=0,this._arr[e].height}}class fn{constructor(e,t,i,s){(e|=0)<0&&(e=0),(t|=0)<0&&(t=0),(i|=0)<0&&(i=0),(s|=0)<0&&(s=0),this.width=e,this.contentWidth=t,this.scrollWidth=Math.max(e,t),this.height=i,this.contentHeight=s,this.scrollHeight=Math.max(i,s)}equals(e){return this.width===e.width&&this.contentWidth===e.contentWidth&&this.height===e.height&&this.contentHeight===e.contentHeight}}class _n extends d.jG{constructor(e,t){super(),this._onDidContentSizeChange=this._register(new h.vl),this.onDidContentSizeChange=this._onDidContentSizeChange.event,this._dimensions=new fn(0,0,0,0),this._scrollable=this._register(new un.yE({forceIntegerValues:!0,smoothScrollDuration:e,scheduleAtNextAnimationFrame:t})),this.onDidScroll=this._scrollable.onScroll}getScrollable(){return this._scrollable}setSmoothScrollDuration(e){this._scrollable.setSmoothScrollDuration(e)}validateScrollPosition(e){return this._scrollable.validateScrollPosition(e)}getScrollDimensions(){return this._dimensions}setScrollDimensions(e){if(this._dimensions.equals(e))return;const t=this._dimensions;this._dimensions=e,this._scrollable.setScrollDimensions({width:e.width,scrollWidth:e.scrollWidth,height:e.height,scrollHeight:e.scrollHeight},!0);const i=t.contentWidth!==e.contentWidth,s=t.contentHeight!==e.contentHeight;(i||s)&&this._onDidContentSizeChange.fire(new Gs(t.contentWidth,t.contentHeight,e.contentWidth,e.contentHeight))}getFutureScrollPosition(){return this._scrollable.getFutureScrollPosition()}getCurrentScrollPosition(){return this._scrollable.getCurrentScrollPosition()}setScrollPositionNow(e){this._scrollable.setScrollPositionNow(e)}setScrollPositionSmooth(e){this._scrollable.setScrollPositionSmooth(e)}hasPendingScrollAnimation(){return this._scrollable.hasPendingScrollAnimation()}}class vn extends d.jG{constructor(e,t,i){super(),this._configuration=e;const s=this._configuration.options,n=s.get(146),r=s.get(84);this._linesLayout=new mn(t,s.get(67),r.top,r.bottom),this._maxLineWidth=0,this._overlayWidgetsMinWidth=0,this._scrollable=this._register(new _n(0,i)),this._configureSmoothScrollDuration(),this._scrollable.setScrollDimensions(new fn(n.contentWidth,0,n.height,0)),this.onDidScroll=this._scrollable.onDidScroll,this.onDidContentSizeChange=this._scrollable.onDidContentSizeChange,this._updateHeight()}dispose(){super.dispose()}getScrollable(){return this._scrollable.getScrollable()}onHeightMaybeChanged(){this._updateHeight()}_configureSmoothScrollDuration(){this._scrollable.setSmoothScrollDuration(this._configuration.options.get(115)?125:0)}onConfigurationChanged(e){const t=this._configuration.options;if(e.hasChanged(67)&&this._linesLayout.setLineHeight(t.get(67)),e.hasChanged(84)){const e=t.get(84);this._linesLayout.setPadding(e.top,e.bottom)}if(e.hasChanged(146)){const e=t.get(146),i=e.contentWidth,s=e.height,n=this._scrollable.getScrollDimensions(),r=n.contentWidth;this._scrollable.setScrollDimensions(new fn(i,n.contentWidth,s,this._getContentHeight(i,s,r)))}else this._updateHeight();e.hasChanged(115)&&this._configureSmoothScrollDuration()}onFlushed(e){this._linesLayout.onFlushed(e)}onLinesDeleted(e,t){this._linesLayout.onLinesDeleted(e,t)}onLinesInserted(e,t){this._linesLayout.onLinesInserted(e,t)}_getHorizontalScrollbarHeight(e,t){const i=this._configuration.options.get(104);return 2===i.horizontal||e>=t?0:i.horizontalScrollbarSize}_getContentHeight(e,t,i){const s=this._configuration.options;let n=this._linesLayout.getLinesTotalHeight();return s.get(106)?n+=Math.max(0,t-s.get(67)-s.get(84).bottom):s.get(104).ignoreHorizontalScrollbarInContentHeight||(n+=this._getHorizontalScrollbarHeight(e,i)),n}_updateHeight(){const e=this._scrollable.getScrollDimensions(),t=e.width,i=e.height,s=e.contentWidth;this._scrollable.setScrollDimensions(new fn(t,e.contentWidth,i,this._getContentHeight(t,i,s)))}getCurrentViewport(){const e=this._scrollable.getScrollDimensions(),t=this._scrollable.getCurrentScrollPosition();return new Vt.LM(t.scrollTop,t.scrollLeft,e.width,e.height)}getFutureViewport(){const e=this._scrollable.getScrollDimensions(),t=this._scrollable.getFutureScrollPosition();return new Vt.LM(t.scrollTop,t.scrollLeft,e.width,e.height)}_computeContentWidth(){const e=this._configuration.options,t=this._maxLineWidth,i=e.get(147),s=e.get(50),n=e.get(146);if(i.isViewportWrapping){const i=e.get(73);return t>n.contentWidth+s.typicalHalfwidthCharacterWidth&&i.enabled&&"right"===i.side?t+n.verticalScrollbarWidth:t}{const i=e.get(105)*s.typicalHalfwidthCharacterWidth,r=this._linesLayout.getWhitespaceMinWidth();return Math.max(t+i+n.verticalScrollbarWidth,r,this._overlayWidgetsMinWidth)}}setMaxLineWidth(e){this._maxLineWidth=e,this._updateContentWidth()}setOverlayWidgetsMinWidth(e){this._overlayWidgetsMinWidth=e,this._updateContentWidth()}_updateContentWidth(){const e=this._scrollable.getScrollDimensions();this._scrollable.setScrollDimensions(new fn(e.width,this._computeContentWidth(),e.height,e.contentHeight)),this._updateHeight()}saveState(){const e=this._scrollable.getFutureScrollPosition(),t=e.scrollTop,i=this._linesLayout.getLineNumberAtOrAfterVerticalOffset(t);return{scrollTop:t,scrollTopWithoutViewZones:t-this._linesLayout.getWhitespaceAccumulatedHeightBeforeLineNumber(i),scrollLeft:e.scrollLeft}}changeWhitespace(e){const t=this._linesLayout.changeWhitespace(e);return t&&this.onHeightMaybeChanged(),t}getVerticalOffsetForLineNumber(e,t=!1){return this._linesLayout.getVerticalOffsetForLineNumber(e,t)}getVerticalOffsetAfterLineNumber(e,t=!1){return this._linesLayout.getVerticalOffsetAfterLineNumber(e,t)}isAfterLines(e){return this._linesLayout.isAfterLines(e)}isInTopPadding(e){return this._linesLayout.isInTopPadding(e)}isInBottomPadding(e){return this._linesLayout.isInBottomPadding(e)}getLineNumberAtVerticalOffset(e){return this._linesLayout.getLineNumberAtOrAfterVerticalOffset(e)}getWhitespaceAtVerticalOffset(e){return this._linesLayout.getWhitespaceAtVerticalOffset(e)}getLinesViewportData(){const e=this.getCurrentViewport();return this._linesLayout.getLinesViewportData(e.top,e.top+e.height)}getLinesViewportDataAtScrollTop(e){const t=this._scrollable.getScrollDimensions();return e+t.height>t.scrollHeight&&(e=t.scrollHeight-t.height),e<0&&(e=0),this._linesLayout.getLinesViewportData(e,e+t.height)}getWhitespaceViewportData(){const e=this.getCurrentViewport();return this._linesLayout.getWhitespaceViewportData(e.top,e.top+e.height)}getWhitespaces(){return this._linesLayout.getWhitespaces()}getContentWidth(){return this._scrollable.getScrollDimensions().contentWidth}getScrollWidth(){return this._scrollable.getScrollDimensions().scrollWidth}getContentHeight(){return this._scrollable.getScrollDimensions().contentHeight}getScrollHeight(){return this._scrollable.getScrollDimensions().scrollHeight}getCurrentScrollLeft(){return this._scrollable.getCurrentScrollPosition().scrollLeft}getCurrentScrollTop(){return this._scrollable.getCurrentScrollPosition().scrollTop}validateScrollPosition(e){return this._scrollable.validateScrollPosition(e)}setScrollPosition(e,t){1===t?this._scrollable.setScrollPositionNow(e):this._scrollable.setScrollPositionSmooth(e)}hasPendingScrollAnimation(){return this._scrollable.hasPendingScrollAnimation()}deltaScrollNow(e,t){const i=this._scrollable.getCurrentScrollPosition();this._scrollable.setScrollPositionNow({scrollLeft:i.scrollLeft+e,scrollTop:i.scrollTop+t})}}var Cn=i(32398),bn=i(87469);function En(e,t){return null===e?t?yn.INSTANCE:wn.INSTANCE:new Sn(e,t)}class Sn{constructor(e,t){this._projectionData=e,this._isVisible=t}isVisible(){return this._isVisible}setVisible(e){return this._isVisible=e,this}getProjectionData(){return this._projectionData}getViewLineCount(){return this._isVisible?this._projectionData.getOutputLineCount():0}getViewLineContent(e,t,i){this._assertVisible();const s=i>0?this._projectionData.breakOffsets[i-1]:0,n=this._projectionData.breakOffsets[i];let r;if(null!==this._projectionData.injectionOffsets){const i=this._projectionData.injectionOffsets.map(((e,t)=>new Gi.uK(0,0,e+1,this._projectionData.injectionOptions[t],0)));r=Gi.uK.applyInjectedText(e.getLineContent(t),i).substring(s,n)}else r=e.getValueInRange({startLineNumber:t,startColumn:s+1,endLineNumber:t,endColumn:n+1});return i>0&&(r=Rn(this._projectionData.wrappedTextIndentLength)+r),r}getViewLineLength(e,t,i){return this._assertVisible(),this._projectionData.getLineLength(i)}getViewLineMinColumn(e,t,i){return this._assertVisible(),this._projectionData.getMinOutputOffset(i)+1}getViewLineMaxColumn(e,t,i){return this._assertVisible(),this._projectionData.getMaxOutputOffset(i)+1}getViewLineData(e,t,i){const s=new Array;return this.getViewLinesData(e,t,i,1,0,[!0],s),s[0]}getViewLinesData(e,t,i,s,n,r,o){this._assertVisible();const a=this._projectionData,l=a.injectionOffsets,c=a.injectionOptions;let h,d=null;if(l){d=[];let e=0,t=0;for(let i=0;i0?a.breakOffsets[i-1]:0,r=a.breakOffsets[i];for(;tr)break;if(n0?a.wrappedTextIndentLength:0,o=t+Math.max(h-n,0),l=t+Math.min(d-n,r-n);o!==l&&s.push(new Vt.or(o,l,e.inlineClassName,e.inlineClassNameAffectsLetterSpacing))}}if(!(d<=r))break;e+=o,t++}}}h=l?e.tokenization.getLineTokens(t).withInserted(l.map(((e,t)=>({offset:e,text:c[t].content,tokenMetadata:bn.f.defaultTokenMetadata})))):e.tokenization.getLineTokens(t);for(let u=i;u0?s.wrappedTextIndentLength:0,r=i>0?s.breakOffsets[i-1]:0,o=s.breakOffsets[i],a=e.sliceAndInflate(r,o,n);let l=a.getLineContent();i>0&&(l=Rn(s.wrappedTextIndentLength)+l);const c=this._projectionData.getMinOutputOffset(i)+1,h=l.length+1,d=i+1=Ln.length)for(let t=1;t<=e;t++)Ln[t]=Tn(t);return Ln[e]}function Tn(e){return new Array(e+1).join(" ")}var xn=i(27414);class kn{constructor(e,t,i,s,n,r,o,a,l,c){this._editorId=e,this.model=t,this._validModelVersionId=-1,this._domLineBreaksComputerFactory=i,this._monospaceLineBreaksComputerFactory=s,this.fontInfo=n,this.tabSize=r,this.wrappingStrategy=o,this.wrappingColumn=a,this.wrappingIndent=l,this.wordBreak=c,this._constructLines(!0,null)}dispose(){this.hiddenAreasDecorationIds=this.model.deltaDecorations(this.hiddenAreasDecorationIds,[])}createCoordinatesConverter(){return new In(this)}_constructLines(e,t){this.modelLineProjections=[],e&&(this.hiddenAreasDecorationIds=this.model.deltaDecorations(this.hiddenAreasDecorationIds,[]));const i=this.model.getLinesContent(),s=this.model.getInjectedTextDecorations(this._editorId),n=i.length,r=this.createLineBreaksComputer(),o=new m.j3(Gi.uK.fromDecorations(s));for(let p=0;pe.lineNumber===p+1));r.addRequest(i[p],e,t?t[p]:null)}const a=r.finalize(),l=[],c=this.hiddenAreasDecorationIds.map((e=>this.model.getDecorationRange(e))).sort(q.Q.compareRangesUsingStarts);let h=1,d=0,u=-1,g=u+1=h&&e<=d,i=En(a[p],!t);l[p]=i.getViewLineCount(),this.modelLineProjections[p]=i}this._validModelVersionId=this.model.getVersionId(),this.projectedModelLineLineCounts=new xn.c2(l)}getHiddenAreas(){return this.hiddenAreasDecorationIds.map((e=>this.model.getDecorationRange(e)))}setHiddenAreas(e){const t=function(e){if(0===e.length)return[];const t=e.slice();t.sort(q.Q.compareRangesUsingStarts);const i=[];let s=t[0].startLineNumber,n=t[0].endLineNumber;for(let r=1,o=t.length;rn+1?(i.push(new q.Q(s,1,n,1)),s=e.startLineNumber,n=e.endLineNumber):e.endLineNumber>n&&(n=e.endLineNumber)}return i.push(new q.Q(s,1,n,1)),i}(e.map((e=>this.model.validateRange(e)))),i=this.hiddenAreasDecorationIds.map((e=>this.model.getDecorationRange(e))).sort(q.Q.compareRangesUsingStarts);if(t.length===i.length){let e=!1;for(let s=0;s({range:e,options:ss.kI.EMPTY})));this.hiddenAreasDecorationIds=this.model.deltaDecorations(this.hiddenAreasDecorationIds,s);const n=t;let r=1,o=0,a=-1,l=a+1=r&&e<=o?this.modelLineProjections[h].isVisible()&&(this.modelLineProjections[h]=this.modelLineProjections[h].setVisible(!1),t=!0):(c=!0,this.modelLineProjections[h].isVisible()||(this.modelLineProjections[h]=this.modelLineProjections[h].setVisible(!0),t=!0)),t){const e=this.modelLineProjections[h].getViewLineCount();this.projectedModelLineLineCounts.setValue(h,e)}}return c||this.setHiddenAreas([]),!0}modelPositionIsVisible(e,t){return!(e<1||e>this.modelLineProjections.length)&&this.modelLineProjections[e-1].isVisible()}getModelLineViewLineCount(e){return e<1||e>this.modelLineProjections.length?1:this.modelLineProjections[e-1].getViewLineCount()}setTabSize(e){return this.tabSize!==e&&(this.tabSize=e,this._constructLines(!1,null),!0)}setWrappingSettings(e,t,i,s,n){const r=this.fontInfo.equals(e),o=this.wrappingStrategy===t,a=this.wrappingColumn===i,l=this.wrappingIndent===s,c=this.wordBreak===n;if(r&&o&&a&&l&&c)return!1;const h=r&&o&&!a&&l&&c;this.fontInfo=e,this.wrappingStrategy=t,this.wrappingColumn=i,this.wrappingIndent=s,this.wordBreak=n;let d=null;if(h){d=[];for(let e=0,t=this.modelLineProjections.length;e2&&!this.modelLineProjections[t-2].isVisible(),r=1===t?1:this.projectedModelLineLineCounts.getPrefixSum(t-1)+1;let o=0;const a=[],l=[];for(let c=0,h=s.length;co?(l=this.projectedModelLineLineCounts.getPrefixSum(t-1)+1,c=l+o-1,u=c+1,g=u+(n-o)-1,a=!0):nt?t:0|e}getActiveIndentGuide(e,t,i){e=this._toValidViewLineNumber(e),t=this._toValidViewLineNumber(t),i=this._toValidViewLineNumber(i);const s=this.convertViewPositionToModelPosition(e,this.getViewLineMinColumn(e)),n=this.convertViewPositionToModelPosition(t,this.getViewLineMinColumn(t)),r=this.convertViewPositionToModelPosition(i,this.getViewLineMinColumn(i)),o=this.model.guides.getActiveIndentGuide(s.lineNumber,n.lineNumber,r.lineNumber),a=this.convertModelPositionToViewPosition(o.startLineNumber,1),l=this.convertModelPositionToViewPosition(o.endLineNumber,this.model.getLineMaxColumn(o.endLineNumber));return{startLineNumber:a.lineNumber,endLineNumber:l.lineNumber,indent:o.indent}}getViewLineInfo(e){e=this._toValidViewLineNumber(e);const t=this.projectedModelLineLineCounts.getIndexOf(e-1),i=t.index,s=t.remainder;return new An(i+1,s)}getMinColumnOfViewLine(e){return this.modelLineProjections[e.modelLineNumber-1].getViewLineMinColumn(this.model,e.modelLineNumber,e.modelLineWrappedLineIdx)}getMaxColumnOfViewLine(e){return this.modelLineProjections[e.modelLineNumber-1].getViewLineMaxColumn(this.model,e.modelLineNumber,e.modelLineWrappedLineIdx)}getModelStartPositionOfViewLine(e){const t=this.modelLineProjections[e.modelLineNumber-1],i=t.getViewLineMinColumn(this.model,e.modelLineNumber,e.modelLineWrappedLineIdx),s=t.getModelColumnOfViewPosition(e.modelLineWrappedLineIdx,i);return new Y.y(e.modelLineNumber,s)}getModelEndPositionOfViewLine(e){const t=this.modelLineProjections[e.modelLineNumber-1],i=t.getViewLineMaxColumn(this.model,e.modelLineNumber,e.modelLineWrappedLineIdx),s=t.getModelColumnOfViewPosition(e.modelLineWrappedLineIdx,i);return new Y.y(e.modelLineNumber,s)}getViewLineInfosGroupedByModelRanges(e,t){const i=this.getViewLineInfo(e),s=this.getViewLineInfo(t),n=new Array;let r=this.getModelStartPositionOfViewLine(i),o=new Array;for(let a=i.modelLineNumber;a<=s.modelLineNumber;a++){const e=this.modelLineProjections[a-1];if(e.isVisible()){const t=a===i.modelLineNumber?i.modelLineWrappedLineIdx:0,n=a===s.modelLineNumber?s.modelLineWrappedLineIdx+1:e.getViewLineCount();for(let e=t;e{if(-1!==e.forWrappedLinesAfterColumn){if(this.modelLineProjections[i.modelLineNumber-1].getViewPositionOfModelPosition(0,e.forWrappedLinesAfterColumn).lineNumber>=i.modelLineWrappedLineIdx)return}if(-1!==e.forWrappedLinesBeforeOrAtColumn){if(this.modelLineProjections[i.modelLineNumber-1].getViewPositionOfModelPosition(0,e.forWrappedLinesBeforeOrAtColumn).lineNumberi.modelLineWrappedLineIdx)return}const s=this.convertModelPositionToViewPosition(i.modelLineNumber,e.horizontalLine.endColumn),n=this.modelLineProjections[i.modelLineNumber-1].getViewPositionOfModelPosition(0,e.horizontalLine.endColumn);return n.lineNumber===i.modelLineWrappedLineIdx?new xt.TH(e.visibleColumn,t,e.className,new xt.pv(e.horizontalLine.top,s.column),-1,-1):n.lineNumber!!e)))}}return r}getViewLinesIndentGuides(e,t){e=this._toValidViewLineNumber(e),t=this._toValidViewLineNumber(t);const i=this.convertViewPositionToModelPosition(e,this.getViewLineMinColumn(e)),s=this.convertViewPositionToModelPosition(t,this.getViewLineMaxColumn(t));let n=[];const r=[],o=[],a=i.lineNumber-1,l=s.lineNumber-1;let c=null;for(let g=a;g<=l;g++){const e=this.modelLineProjections[g];if(e.isVisible()){const t=e.getViewLineNumberOfModelPosition(0,g===a?i.column:1),s=e.getViewLineNumberOfModelPosition(0,this.model.getLineMaxColumn(g+1)),n=s-t+1;let l=0;n>1&&1===e.getViewLineMinColumn(this.model,g+1,s)&&(l=0===t?1:2),r.push(n),o.push(l),null===c&&(c=new Y.y(g+1,0))}else null!==c&&(n=n.concat(this.model.guides.getLinesIndentGuides(c.lineNumber,g)),c=null)}null!==c&&(n=n.concat(this.model.guides.getLinesIndentGuides(c.lineNumber,s.lineNumber)),c=null);const h=t-e+1,d=new Array(h);let u=0;for(let g=0,p=n.length;gt&&(d=!0,h=t-n+1),s.getViewLinesData(this.model,l+1,c,h,n-e,i,a),n+=h,d)break}return a}validateViewPosition(e,t,i){e=this._toValidViewLineNumber(e);const s=this.projectedModelLineLineCounts.getIndexOf(e-1),n=s.index,r=s.remainder,o=this.modelLineProjections[n],a=o.getViewLineMinColumn(this.model,n+1,r),l=o.getViewLineMaxColumn(this.model,n+1,r);tl&&(t=l);const c=o.getModelColumnOfViewPosition(r,t);return this.model.validatePosition(new Y.y(n+1,c)).equals(i)?new Y.y(e,t):this.convertModelPositionToViewPosition(i.lineNumber,i.column)}validateViewRange(e,t){const i=this.validateViewPosition(e.startLineNumber,e.startColumn,t.getStartPosition()),s=this.validateViewPosition(e.endLineNumber,e.endColumn,t.getEndPosition());return new q.Q(i.lineNumber,i.column,s.lineNumber,s.column)}convertViewPositionToModelPosition(e,t){const i=this.getViewLineInfo(e),s=this.modelLineProjections[i.modelLineNumber-1].getModelColumnOfViewPosition(i.modelLineWrappedLineIdx,t);return this.model.validatePosition(new Y.y(i.modelLineNumber,s))}convertViewRangeToModelRange(e){const t=this.convertViewPositionToModelPosition(e.startLineNumber,e.startColumn),i=this.convertViewPositionToModelPosition(e.endLineNumber,e.endColumn);return new q.Q(t.lineNumber,t.column,i.lineNumber,i.column)}convertModelPositionToViewPosition(e,t,i=2,s=!1,n=!1){const r=this.model.validatePosition(new Y.y(e,t)),o=r.lineNumber,a=r.column;let l=o-1,c=!1;if(n)for(;l0&&!this.modelLineProjections[l].isVisible();)l--,c=!0;if(0===l&&!this.modelLineProjections[l].isVisible())return new Y.y(s?0:1,1);const h=1+this.projectedModelLineLineCounts.getPrefixSum(l);let d;return d=c?n?this.modelLineProjections[l].getViewPositionOfModelPosition(h,1,i):this.modelLineProjections[l].getViewPositionOfModelPosition(h,this.model.getLineMaxColumn(l+1),i):this.modelLineProjections[o-1].getViewPositionOfModelPosition(h,a,i),d}convertModelRangeToViewRange(e,t=0){if(e.isEmpty()){const i=this.convertModelPositionToViewPosition(e.startLineNumber,e.startColumn,t);return q.Q.fromPositions(i)}{const t=this.convertModelPositionToViewPosition(e.startLineNumber,e.startColumn,1),i=this.convertModelPositionToViewPosition(e.endLineNumber,e.endColumn,0);return new q.Q(t.lineNumber,t.column,i.lineNumber,i.column)}}getViewLineNumberOfModelPosition(e,t){let i=e-1;if(this.modelLineProjections[i].isVisible()){const e=1+this.projectedModelLineLineCounts.getPrefixSum(i);return this.modelLineProjections[i].getViewLineNumberOfModelPosition(e,t)}for(;i>0&&!this.modelLineProjections[i].isVisible();)i--;if(0===i&&!this.modelLineProjections[i].isVisible())return 1;const s=1+this.projectedModelLineLineCounts.getPrefixSum(i);return this.modelLineProjections[i].getViewLineNumberOfModelPosition(s,this.model.getLineMaxColumn(i+1))}getDecorationsInRange(e,t,i,s,n){const r=this.convertViewPositionToModelPosition(e.startLineNumber,e.startColumn),o=this.convertViewPositionToModelPosition(e.endLineNumber,e.endColumn);if(o.lineNumber-r.lineNumber<=e.endLineNumber-e.startLineNumber)return this.model.getDecorationsInRange(new q.Q(r.lineNumber,1,o.lineNumber,o.column),t,i,s,n);let a=[];const l=r.lineNumber-1,c=o.lineNumber-1;let h=null;for(let p=l;p<=c;p++){if(this.modelLineProjections[p].isVisible())null===h&&(h=new Y.y(p+1,p===l?r.column:1));else if(null!==h){const e=this.model.getLineMaxColumn(p);a=a.concat(this.model.getDecorationsInRange(new q.Q(h.lineNumber,h.column,p,e),t,i,s)),h=null}}null!==h&&(a=a.concat(this.model.getDecorationsInRange(new q.Q(h.lineNumber,h.column,o.lineNumber,o.column),t,i,s)),h=null),a.sort(((e,t)=>{const i=q.Q.compareRangesUsingStarts(e.range,t.range);return 0===i?e.idt.id?1:0:i}));const d=[];let u=0,g=null;for(const p of a){const e=p.id;g!==e&&(g=e,d[u++]=p)}return d}getInjectedTextAt(e){const t=this.getViewLineInfo(e.lineNumber);return this.modelLineProjections[t.modelLineNumber-1].getInjectedTextAt(t.modelLineWrappedLineIdx,e.column)}normalizePosition(e,t){const i=this.getViewLineInfo(e.lineNumber);return this.modelLineProjections[i.modelLineNumber-1].normalizePosition(i.modelLineWrappedLineIdx,e,t)}getLineIndentColumn(e){const t=this.getViewLineInfo(e);return 0===t.modelLineWrappedLineIdx?this.model.getLineIndentColumn(t.modelLineNumber):0}}class An{constructor(e,t){this.modelLineNumber=e,this.modelLineWrappedLineIdx=t}}class Nn{constructor(e,t){this.modelRange=e,this.viewLines=t}}class In{constructor(e){this._lines=e}convertViewPositionToModelPosition(e){return this._lines.convertViewPositionToModelPosition(e.lineNumber,e.column)}convertViewRangeToModelRange(e){return this._lines.convertViewRangeToModelRange(e)}validateViewPosition(e,t){return this._lines.validateViewPosition(e.lineNumber,e.column,t)}validateViewRange(e,t){return this._lines.validateViewRange(e,t)}convertModelPositionToViewPosition(e,t,i,s){return this._lines.convertModelPositionToViewPosition(e.lineNumber,e.column,t,i,s)}convertModelRangeToViewRange(e,t){return this._lines.convertModelRangeToViewRange(e,t)}modelPositionIsVisible(e){return this._lines.modelPositionIsVisible(e.lineNumber,e.column)}getModelLineViewLineCount(e){return this._lines.getModelLineViewLineCount(e)}getViewLineNumberOfModelPosition(e,t){return this._lines.getViewLineNumberOfModelPosition(e,t)}}class On{constructor(e){this.model=e}dispose(){}createCoordinatesConverter(){return new Dn(this)}getHiddenAreas(){return[]}setHiddenAreas(e){return!1}setTabSize(e){return!1}setWrappingSettings(e,t,i,s){return!1}createLineBreaksComputer(){const e=[];return{addRequest:(t,i,s)=>{e.push(null)},finalize:()=>e}}onModelFlushed(){}onModelLinesDeleted(e,t,i){return new Ds(t,i)}onModelLinesInserted(e,t,i,s){return new Ms(t,i)}onModelLineChanged(e,t,i){return[!1,new Os(t,1),null,null]}acceptVersionId(e){}getViewLineCount(){return this.model.getLineCount()}getActiveIndentGuide(e,t,i){return{startLineNumber:e,endLineNumber:e,indent:0}}getViewLinesBracketGuides(e,t,i){return new Array(t-e+1).fill([])}getViewLinesIndentGuides(e,t){const i=t-e+1,s=new Array(i);for(let n=0;nt)}getModelLineViewLineCount(e){return 1}getViewLineNumberOfModelPosition(e,t){return e}}const Mn=_t.ZS.Right;class Pn{constructor(e){this.persist=0,this._requiredLanes=1,this.lanes=new Uint8Array(Math.ceil((e+1)*Mn/8))}reset(e){const t=Math.ceil((e+1)*Mn/8);this.lanes.length>>3]|=1<>>3]&1<>>3]&1<this._updateConfigurationViewLineCountNow()),0)),this._hasFocus=!1,this._viewportStart=Un.create(this.model),this.glyphLanes=new Pn(0),this.model.isTooLargeForTokenization())this._lines=new On(this.model);else{const e=this._configuration.options,t=e.get(50),i=e.get(140),r=e.get(147),o=e.get(139),a=e.get(130);this._lines=new kn(this._editorId,this.model,s,n,t,this.model.getOptions().tabSize,i,r.wrappingColumn,o,a)}this.coordinatesConverter=this._lines.createCoordinatesConverter(),this._cursor=this._register(new nn(i,this,this.coordinatesConverter,this.cursorConfig)),this.viewLayout=this._register(new vn(this._configuration,this.getLineCount(),r)),this._register(this.viewLayout.onDidScroll((e=>{e.scrollTopChanged&&this._handleVisibleLinesChanged(),e.scrollTopChanged&&this._viewportStart.invalidate(),this._eventDispatcher.emitSingleViewEvent(new Fs(e)),this._eventDispatcher.emitOutgoingEvent(new Ks(e.oldScrollWidth,e.oldScrollLeft,e.oldScrollHeight,e.oldScrollTop,e.scrollWidth,e.scrollLeft,e.scrollHeight,e.scrollTop))}))),this._register(this.viewLayout.onDidContentSizeChange((e=>{this._eventDispatcher.emitOutgoingEvent(e)}))),this._decorations=new Cn.UB(this._editorId,this.model,this._configuration,this._lines,this.coordinatesConverter),this._registerModelEvents(),this._register(this._configuration.onDidChangeFast((e=>{try{const t=this._eventDispatcher.beginEmitViewEvents();this._onConfigurationChanged(t,e)}finally{this._eventDispatcher.endEmitViewEvents()}}))),this._register(Wt.getInstance().onDidChange((()=>{this._eventDispatcher.emitSingleViewEvent(new Bs)}))),this._register(this._themeService.onDidColorThemeChange((e=>{this._invalidateDecorationsColorCache(),this._eventDispatcher.emitSingleViewEvent(new Us(e))}))),this._updateConfigurationViewLineCountNow()}dispose(){super.dispose(),this._decorations.dispose(),this._lines.dispose(),this._viewportStart.dispose(),this._eventDispatcher.dispose()}createLineBreaksComputer(){return this._lines.createLineBreaksComputer()}addViewEventHandler(e){this._eventDispatcher.addViewEventHandler(e)}removeViewEventHandler(e){this._eventDispatcher.removeViewEventHandler(e)}_updateConfigurationViewLineCountNow(){this._configuration.setViewLineCount(this._lines.getViewLineCount())}getModelVisibleRanges(){const e=this.viewLayout.getLinesViewportData(),t=new q.Q(e.startLineNumber,this.getLineMinColumn(e.startLineNumber),e.endLineNumber,this.getLineMaxColumn(e.endLineNumber));return this._toModelVisibleRanges(t)}visibleLinesStabilized(){const e=this.getModelVisibleRanges();this._attachedView.setVisibleLines(e,!0)}_handleVisibleLinesChanged(){const e=this.getModelVisibleRanges();this._attachedView.setVisibleLines(e,!1)}setHasFocus(e){this._hasFocus=e,this._cursor.setHasFocus(e),this._eventDispatcher.emitSingleViewEvent(new As(e)),this._eventDispatcher.emitOutgoingEvent(new js(!e,e))}onCompositionStart(){this._eventDispatcher.emitSingleViewEvent(new ws)}onCompositionEnd(){this._eventDispatcher.emitSingleViewEvent(new Ls)}_captureStableViewport(){if(this._viewportStart.isValid&&this.viewLayout.getCurrentScrollTop()>0){const e=new Y.y(this._viewportStart.viewLineNumber,this.getLineMinColumn(this._viewportStart.viewLineNumber)),t=this.coordinatesConverter.convertViewPositionToModelPosition(e);return new Vn(t,this._viewportStart.startLineDelta)}return new Vn(null,0)}_onConfigurationChanged(e,t){const i=this._captureStableViewport(),s=this._configuration.options,n=s.get(50),r=s.get(140),o=s.get(147),a=s.get(139),l=s.get(130);this._lines.setWrappingSettings(n,r,o.wrappingColumn,a,l)&&(e.emitViewEvent(new ks),e.emitViewEvent(new Is),e.emitViewEvent(new xs(null)),this._cursor.onLineMappingChanged(e),this._decorations.onLineMappingChanged(),this.viewLayout.onFlushed(this.getLineCount()),this._updateConfigurationViewLineCount.schedule()),t.hasChanged(92)&&(this._decorations.reset(),e.emitViewEvent(new xs(null))),t.hasChanged(99)&&(this._decorations.reset(),e.emitViewEvent(new xs(null))),e.emitViewEvent(new Rs(t)),this.viewLayout.onConfigurationChanged(t),i.recoverViewportStart(this.coordinatesConverter,this.viewLayout),_s.d$.shouldRecreate(t)&&(this.cursorConfig=new _s.d$(this.model.getLanguageId(),this.model.getOptions(),this._configuration,this.languageConfigurationService),this._cursor.updateConfiguration(this.cursorConfig))}_registerModelEvents(){this._register(this.model.onDidChangeContentOrInjectedText((e=>{try{const t=this._eventDispatcher.beginEmitViewEvents();let i=!1,s=!1;const n=e instanceof Gi.Ic?e.rawContentChangedEvent.changes:e.changes,r=e instanceof Gi.Ic?e.rawContentChangedEvent.versionId:null,o=this._lines.createLineBreaksComputer();for(const e of n)switch(e.changeType){case 4:for(let t=0;t!e.ownerId||e.ownerId===this._editorId))),o.addRequest(i,s,null)}break;case 2:{let t=null;e.injectedText&&(t=e.injectedText.filter((e=>!e.ownerId||e.ownerId===this._editorId))),o.addRequest(e.detail,t,null);break}}const a=o.finalize(),l=new m.j3(a);for(const e of n)switch(e.changeType){case 1:this._lines.onModelFlushed(),t.emitViewEvent(new ks),this._decorations.reset(),this.viewLayout.onFlushed(this.getLineCount()),i=!0;break;case 3:{const s=this._lines.onModelLinesDeleted(r,e.fromLineNumber,e.toLineNumber);null!==s&&(t.emitViewEvent(s),this.viewLayout.onLinesDeleted(s.fromLineNumber,s.toLineNumber)),i=!0;break}case 4:{const s=l.takeCount(e.detail.length),n=this._lines.onModelLinesInserted(r,e.fromLineNumber,e.toLineNumber,s);null!==n&&(t.emitViewEvent(n),this.viewLayout.onLinesInserted(n.fromLineNumber,n.toLineNumber)),i=!0;break}case 2:{const i=l.dequeue(),[n,o,a,c]=this._lines.onModelLineChanged(r,e.lineNumber,i);s=n,o&&t.emitViewEvent(o),a&&(t.emitViewEvent(a),this.viewLayout.onLinesInserted(a.fromLineNumber,a.toLineNumber)),c&&(t.emitViewEvent(c),this.viewLayout.onLinesDeleted(c.fromLineNumber,c.toLineNumber));break}}null!==r&&this._lines.acceptVersionId(r),this.viewLayout.onHeightMaybeChanged(),!i&&s&&(t.emitViewEvent(new Is),t.emitViewEvent(new xs(null)),this._cursor.onLineMappingChanged(t),this._decorations.onLineMappingChanged())}finally{this._eventDispatcher.endEmitViewEvents()}const t=this._viewportStart.isValid;if(this._viewportStart.invalidate(),this._configuration.setModelLineCount(this.model.getLineCount()),this._updateConfigurationViewLineCountNow(),!this._hasFocus&&this.model.getAttachedEditorCount()>=2&&t){const e=this.model._getTrackedRange(this._viewportStart.modelTrackedRange);if(e){const t=this.coordinatesConverter.convertModelPositionToViewPosition(e.getStartPosition()),i=this.viewLayout.getVerticalOffsetForLineNumber(t.lineNumber);this.viewLayout.setScrollPosition({scrollTop:i+this._viewportStart.startLineDelta},1)}}try{const t=this._eventDispatcher.beginEmitViewEvents();e instanceof Gi.Ic&&t.emitOutgoingEvent(new en(e.contentChangedEvent)),this._cursor.onModelContentChanged(t,e)}finally{this._eventDispatcher.endEmitViewEvents()}this._handleVisibleLinesChanged()}))),this._register(this.model.onDidChangeTokens((e=>{const t=[];for(let i=0,s=e.ranges.length;i{this._eventDispatcher.emitSingleViewEvent(new Ns),this.cursorConfig=new _s.d$(this.model.getLanguageId(),this.model.getOptions(),this._configuration,this.languageConfigurationService),this._cursor.updateConfiguration(this.cursorConfig),this._eventDispatcher.emitOutgoingEvent(new Js(e))}))),this._register(this.model.onDidChangeLanguage((e=>{this.cursorConfig=new _s.d$(this.model.getLanguageId(),this.model.getOptions(),this._configuration,this.languageConfigurationService),this._cursor.updateConfiguration(this.cursorConfig),this._eventDispatcher.emitOutgoingEvent(new Zs(e))}))),this._register(this.model.onDidChangeOptions((e=>{if(this._lines.setTabSize(this.model.getOptions().tabSize)){try{const e=this._eventDispatcher.beginEmitViewEvents();e.emitViewEvent(new ks),e.emitViewEvent(new Is),e.emitViewEvent(new xs(null)),this._cursor.onLineMappingChanged(e),this._decorations.onLineMappingChanged(),this.viewLayout.onFlushed(this.getLineCount())}finally{this._eventDispatcher.endEmitViewEvents()}this._updateConfigurationViewLineCount.schedule()}this.cursorConfig=new _s.d$(this.model.getLanguageId(),this.model.getOptions(),this._configuration,this.languageConfigurationService),this._cursor.updateConfiguration(this.cursorConfig),this._eventDispatcher.emitOutgoingEvent(new tn(e))}))),this._register(this.model.onDidChangeDecorations((e=>{this._decorations.onModelDecorationsChanged(),this._eventDispatcher.emitSingleViewEvent(new xs(e)),this._eventDispatcher.emitOutgoingEvent(new Xs(e))})))}setHiddenAreas(e,t){this.hiddenAreasModel.setHiddenAreas(t,e);const i=this.hiddenAreasModel.getMergedRanges();if(i===this.previousHiddenAreas)return;this.previousHiddenAreas=i;const s=this._captureStableViewport();let n=!1;try{const e=this._eventDispatcher.beginEmitViewEvents();n=this._lines.setHiddenAreas(i),n&&(e.emitViewEvent(new ks),e.emitViewEvent(new Is),e.emitViewEvent(new xs(null)),this._cursor.onLineMappingChanged(e),this._decorations.onLineMappingChanged(),this.viewLayout.onFlushed(this.getLineCount()),this.viewLayout.onHeightMaybeChanged());const t=s.viewportStartModelPosition?.lineNumber;t&&i.some((e=>e.startLineNumber<=t&&t<=e.endLineNumber))||s.recoverViewportStart(this.coordinatesConverter,this.viewLayout)}finally{this._eventDispatcher.endEmitViewEvents()}this._updateConfigurationViewLineCount.schedule(),n&&this._eventDispatcher.emitOutgoingEvent(new qs)}getVisibleRangesPlusViewportAboveBelow(){const e=this._configuration.options.get(146),t=this._configuration.options.get(67),i=Math.max(20,Math.round(e.height/t)),s=this.viewLayout.getLinesViewportData(),n=Math.max(1,s.completelyVisibleStartLineNumber-i),r=Math.min(this.getLineCount(),s.completelyVisibleEndLineNumber+i);return this._toModelVisibleRanges(new q.Q(n,this.getLineMinColumn(n),r,this.getLineMaxColumn(r)))}getVisibleRanges(){const e=this.getCompletelyVisibleViewRange();return this._toModelVisibleRanges(e)}getHiddenAreas(){return this._lines.getHiddenAreas()}_toModelVisibleRanges(e){const t=this.coordinatesConverter.convertViewRangeToModelRange(e),i=this._lines.getHiddenAreas();if(0===i.length)return[t];const s=[];let n=0,r=t.startLineNumber,o=t.startColumn;const a=t.endLineNumber,l=t.endColumn;for(let c=0,h=i.length;ca||(rt.toInlineDecoration(e)))]),new Vt.qL(r.minColumn,r.maxColumn,r.content,r.continuesWithWrappedLine,i,s,r.tokens,t,n,r.startVisibleColumn)}getViewLineData(e){return this._lines.getViewLineData(e)}getMinimapLinesRenderingData(e,t,i){const s=this._lines.getViewLinesData(e,t,i);return new Vt.nt(this.getTabSize(),s)}getAllOverviewRulerDecorations(e){const t=this.model.getOverviewRulerDecorations(this._editorId,(0,L.$C)(this._configuration.options)),i=new Hn;for(const s of t){const t=s.options,n=t.overviewRuler;if(!n)continue;const r=n.position;if(0===r)continue;const o=n.getColor(e.value),a=this.coordinatesConverter.getViewLineNumberOfModelPosition(s.range.startLineNumber,s.range.startColumn),l=this.coordinatesConverter.getViewLineNumberOfModelPosition(s.range.endLineNumber,s.range.endColumn);i.accept(o,t.zIndex,a,l,r)}return i.asArray}_invalidateDecorationsColorCache(){const e=this.model.getOverviewRulerDecorations();for(const t of e){const e=t.options.overviewRuler;e?.invalidateCachedColor();const i=t.options.minimap;i?.invalidateCachedColor()}}getValueInRange(e,t){const i=this.coordinatesConverter.convertViewRangeToModelRange(e);return this.model.getValueInRange(i,t)}getValueLengthInRange(e,t){const i=this.coordinatesConverter.convertViewRangeToModelRange(e);return this.model.getValueLengthInRange(i,t)}modifyPosition(e,t){const i=this.coordinatesConverter.convertViewPositionToModelPosition(e),s=this.model.modifyPosition(i,t);return this.coordinatesConverter.convertModelPositionToViewPosition(s)}deduceModelPositionRelativeToViewPosition(e,t,i){const s=this.coordinatesConverter.convertViewPositionToModelPosition(e);2===this.model.getEOL().length&&(t<0?t-=i:t+=i);const n=this.model.getOffsetAt(s)+t;return this.model.getPositionAt(n)}getPlainTextToCopy(e,t,i){const s=i?"\r\n":this.model.getEOL();(e=e.slice(0)).sort(q.Q.compareRangesUsingStarts);let n=!1,r=!1;for(const a of e)a.isEmpty()?n=!0:r=!0;if(!r){if(!t)return"";const i=e.map((e=>e.startLineNumber));let n="";for(let e=0;e0&&i[e-1]===i[e]||(n+=this.model.getLineContent(i[e])+s);return n}if(n&&t){const t=[];let s=0;for(const n of e){const e=n.startLineNumber;n.isEmpty()?e!==s&&t.push(this.model.getLineContent(e)):t.push(this.model.getValueInRange(n,i?2:0)),s=e}return 1===t.length?t[0]:t}const o=[];for(const a of e)a.isEmpty()||o.push(this.model.getValueInRange(a,i?2:0));return 1===o.length?o[0]:o}getRichTextToCopy(e,t){const i=this.model.getLanguageId();if(i===hn.vH)return null;if(1!==e.length)return null;let s=e[0];if(s.isEmpty()){if(!t)return null;const e=s.startLineNumber;s=new q.Q(e,this.model.getLineMinColumn(e),e,this.model.getLineMaxColumn(e))}const n=this._configuration.options.get(50),r=this._getColorMap();let o;if(/[:;\\\/<>]/.test(n.fontFamily)||n.fontFamily===L.jU.fontFamily)o=L.jU.fontFamily;else{o=n.fontFamily,o=o.replace(/"/g,"'");if(!/[,']/.test(o)){/[+ ]/.test(o)&&(o=`'${o}'`)}o=`${o}, ${L.jU.fontFamily}`}return{mode:i,html:`
    `+this._getHTMLToCopy(s,r)+"
    "}}_getHTMLToCopy(e,t){const i=e.startLineNumber,s=e.startColumn,n=e.endLineNumber,r=e.endColumn,o=this.getTabSize();let a="";for(let l=i;l<=n;l++){const e=this.model.tokenization.getLineTokens(l),c=e.getLineContent(),h=l===i?s-1:0,d=l===n?r-1:c.length;a+=""===c?"
    ":(0,dn.s0)(c,e.inflate(),t,h,d,o,_.uF)}return a}_getColorMap(){const e=Me.dG.getColorMap(),t=["#000000"];if(e)for(let i=1,s=e.length;ithis._cursor.setStates(s,e,t,i)))}getCursorColumnSelectData(){return this._cursor.getCursorColumnSelectData()}getCursorAutoClosedCharacters(){return this._cursor.getAutoClosedCharacters()}setCursorColumnSelectData(e){this._cursor.setCursorColumnSelectData(e)}getPrevEditOperationType(){return this._cursor.getPrevEditOperationType()}setPrevEditOperationType(e){this._cursor.setPrevEditOperationType(e)}getSelection(){return this._cursor.getSelection()}getSelections(){return this._cursor.getSelections()}getPosition(){return this._cursor.getPrimaryCursorState().modelState.position}setSelections(e,t,i=0){this._withViewEventsCollector((s=>this._cursor.setSelections(s,e,t,i)))}saveCursorState(){return this._cursor.saveState()}restoreCursorState(e){this._withViewEventsCollector((t=>this._cursor.restoreState(t,e)))}_executeCursorEdit(e){this._cursor.context.cursorConfig.readOnly?this._eventDispatcher.emitOutgoingEvent(new Qs):this._withViewEventsCollector(e)}executeEdits(e,t,i){this._executeCursorEdit((s=>this._cursor.executeEdits(s,e,t,i)))}startComposition(){this._executeCursorEdit((e=>this._cursor.startComposition(e)))}endComposition(e){this._executeCursorEdit((t=>this._cursor.endComposition(t,e)))}type(e,t){this._executeCursorEdit((i=>this._cursor.type(i,e,t)))}compositionType(e,t,i,s,n){this._executeCursorEdit((r=>this._cursor.compositionType(r,e,t,i,s,n)))}paste(e,t,i,s){this._executeCursorEdit((n=>this._cursor.paste(n,e,t,i,s)))}cut(e){this._executeCursorEdit((t=>this._cursor.cut(t,e)))}executeCommand(e,t){this._executeCursorEdit((i=>this._cursor.executeCommand(i,e,t)))}executeCommands(e,t){this._executeCursorEdit((i=>this._cursor.executeCommands(i,e,t)))}revealAllCursors(e,t,i=!1){this._withViewEventsCollector((s=>this._cursor.revealAll(s,e,i,0,t,0)))}revealPrimaryCursor(e,t,i=!1){this._withViewEventsCollector((s=>this._cursor.revealPrimary(s,e,i,0,t,0)))}revealTopMostCursor(e){const t=this._cursor.getTopMostViewPosition(),i=new q.Q(t.lineNumber,t.column,t.lineNumber,t.column);this._withViewEventsCollector((t=>t.emitViewEvent(new Ps(e,!1,i,null,0,!0,0))))}revealBottomMostCursor(e){const t=this._cursor.getBottomMostViewPosition(),i=new q.Q(t.lineNumber,t.column,t.lineNumber,t.column);this._withViewEventsCollector((t=>t.emitViewEvent(new Ps(e,!1,i,null,0,!0,0))))}revealRange(e,t,i,s,n){this._withViewEventsCollector((r=>r.emitViewEvent(new Ps(e,!1,i,null,s,t,n))))}changeWhitespace(e){this.viewLayout.changeWhitespace(e)&&(this._eventDispatcher.emitSingleViewEvent(new Ws),this._eventDispatcher.emitOutgoingEvent(new Ys))}_withViewEventsCollector(e){return this._transactionalTarget.batchChanges((()=>{try{const t=this._eventDispatcher.beginEmitViewEvents();return e(t)}finally{this._eventDispatcher.endEmitViewEvents()}}))}batchEvents(e){this._withViewEventsCollector((()=>{e()}))}normalizePosition(e,t){return this._lines.normalizePosition(e,t)}getLineIndentColumn(e){return this._lines.getLineIndentColumn(e)}}class Un{static create(e){const t=e._setTrackedRange(null,new q.Q(1,1,1,1),1);return new Un(e,1,!1,t,0)}get viewLineNumber(){return this._viewLineNumber}get isValid(){return this._isValid}get modelTrackedRange(){return this._modelTrackedRange}get startLineDelta(){return this._startLineDelta}constructor(e,t,i,s,n){this._model=e,this._viewLineNumber=t,this._isValid=i,this._modelTrackedRange=s,this._startLineDelta=n}dispose(){this._model._setTrackedRange(this._modelTrackedRange,null,1)}update(e,t){const i=e.coordinatesConverter.convertViewPositionToModelPosition(new Y.y(t,e.getLineMinColumn(t))),s=e.model._setTrackedRange(this._modelTrackedRange,new q.Q(i.lineNumber,i.column,i.lineNumber,i.column),1),n=e.viewLayout.getVerticalOffsetForLineNumber(t),r=e.viewLayout.getCurrentScrollTop();this._viewLineNumber=t,this._isValid=!0,this._modelTrackedRange=s,this._startLineDelta=r-n}invalidate(){this._isValid=!1}}class Hn{constructor(){this._asMap=Object.create(null),this.asArray=[]}accept(e,t,i,s,n){const r=this._asMap[e];if(r){const e=r.data,t=e[e.length-3],o=e[e.length-1];if(t===n&&o+1>=i)return void(s>o&&(e[e.length-1]=s));e.push(n,i,s)}else{const r=new Vt.Uv(e,t,[n,i,s]);this._asMap[e]=r,this.asArray.push(r)}}}class Bn{constructor(){this.hiddenAreas=new Map,this.shouldRecompute=!1,this.ranges=[]}setHiddenAreas(e,t){const i=this.hiddenAreas.get(e);i&&Wn(i,t)||(this.hiddenAreas.set(e,t),this.shouldRecompute=!0)}getMergedRanges(){if(!this.shouldRecompute)return this.ranges;this.shouldRecompute=!1;const e=Array.from(this.hiddenAreas.values()).reduce(((e,t)=>function(e,t){const i=[];let s=0,n=0;for(;s=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Qn=function(e,t){return function(i,s){t(i,s,e)}};let Xn=class extends d.jG{static{zn=this}static{this.dropIntoEditorDecorationOptions=ss.kI.register({description:"workbench-dnd-target",className:"dnd-target"})}get isSimpleWidget(){return this._configuration.isSimpleWidget}get contextMenuId(){return this._configuration.contextMenuId}constructor(e,t,i,s,r,o,a,d,u,g,p,m){super(),this.languageConfigurationService=p,this._deliveryQueue=(0,h.Qy)(),this._contributions=this._register(new Xi),this._onDidDispose=this._register(new h.vl),this.onDidDispose=this._onDidDispose.event,this._onDidChangeModelContent=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModelContent=this._onDidChangeModelContent.event,this._onDidChangeModelLanguage=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModelLanguage=this._onDidChangeModelLanguage.event,this._onDidChangeModelLanguageConfiguration=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModelLanguageConfiguration=this._onDidChangeModelLanguageConfiguration.event,this._onDidChangeModelOptions=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModelOptions=this._onDidChangeModelOptions.event,this._onDidChangeModelDecorations=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModelDecorations=this._onDidChangeModelDecorations.event,this._onDidChangeModelTokens=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModelTokens=this._onDidChangeModelTokens.event,this._onDidChangeConfiguration=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeConfiguration=this._onDidChangeConfiguration.event,this._onWillChangeModel=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onWillChangeModel=this._onWillChangeModel.event,this._onDidChangeModel=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeModel=this._onDidChangeModel.event,this._onDidChangeCursorPosition=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeCursorPosition=this._onDidChangeCursorPosition.event,this._onDidChangeCursorSelection=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeCursorSelection=this._onDidChangeCursorSelection.event,this._onDidAttemptReadOnlyEdit=this._register(new tr(this._contributions,this._deliveryQueue)),this.onDidAttemptReadOnlyEdit=this._onDidAttemptReadOnlyEdit.event,this._onDidLayoutChange=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidLayoutChange=this._onDidLayoutChange.event,this._editorTextFocus=this._register(new er({deliveryQueue:this._deliveryQueue})),this.onDidFocusEditorText=this._editorTextFocus.onDidChangeToTrue,this.onDidBlurEditorText=this._editorTextFocus.onDidChangeToFalse,this._editorWidgetFocus=this._register(new er({deliveryQueue:this._deliveryQueue})),this.onDidFocusEditorWidget=this._editorWidgetFocus.onDidChangeToTrue,this.onDidBlurEditorWidget=this._editorWidgetFocus.onDidChangeToFalse,this._onWillType=this._register(new tr(this._contributions,this._deliveryQueue)),this.onWillType=this._onWillType.event,this._onDidType=this._register(new tr(this._contributions,this._deliveryQueue)),this.onDidType=this._onDidType.event,this._onDidCompositionStart=this._register(new tr(this._contributions,this._deliveryQueue)),this.onDidCompositionStart=this._onDidCompositionStart.event,this._onDidCompositionEnd=this._register(new tr(this._contributions,this._deliveryQueue)),this.onDidCompositionEnd=this._onDidCompositionEnd.event,this._onDidPaste=this._register(new tr(this._contributions,this._deliveryQueue)),this.onDidPaste=this._onDidPaste.event,this._onMouseUp=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseUp=this._onMouseUp.event,this._onMouseDown=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseDown=this._onMouseDown.event,this._onMouseDrag=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseDrag=this._onMouseDrag.event,this._onMouseDrop=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseDrop=this._onMouseDrop.event,this._onMouseDropCanceled=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseDropCanceled=this._onMouseDropCanceled.event,this._onDropIntoEditor=this._register(new tr(this._contributions,this._deliveryQueue)),this.onDropIntoEditor=this._onDropIntoEditor.event,this._onContextMenu=this._register(new tr(this._contributions,this._deliveryQueue)),this.onContextMenu=this._onContextMenu.event,this._onMouseMove=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseMove=this._onMouseMove.event,this._onMouseLeave=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseLeave=this._onMouseLeave.event,this._onMouseWheel=this._register(new tr(this._contributions,this._deliveryQueue)),this.onMouseWheel=this._onMouseWheel.event,this._onKeyUp=this._register(new tr(this._contributions,this._deliveryQueue)),this.onKeyUp=this._onKeyUp.event,this._onKeyDown=this._register(new tr(this._contributions,this._deliveryQueue)),this.onKeyDown=this._onKeyDown.event,this._onDidContentSizeChange=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidContentSizeChange=this._onDidContentSizeChange.event,this._onDidScrollChange=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidScrollChange=this._onDidScrollChange.event,this._onDidChangeViewZones=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeViewZones=this._onDidChangeViewZones.event,this._onDidChangeHiddenAreas=this._register(new h.vl({deliveryQueue:this._deliveryQueue})),this.onDidChangeHiddenAreas=this._onDidChangeHiddenAreas.event,this._updateCounter=0,this._onBeginUpdate=this._register(new h.vl),this.onBeginUpdate=this._onBeginUpdate.event,this._onEndUpdate=this._register(new h.vl),this.onEndUpdate=this._onEndUpdate.event,this._actions=new Map,this._bannerDomNode=null,this._dropIntoEditorDecorations=this.createDecorationsCollection(),r.willCreateCodeEditor();const f={...t};let _;this._domElement=e,this._overflowWidgetsDomNode=f.overflowWidgetsDomNode,delete f.overflowWidgetsDomNode,this._id=++Zn,this._decorationTypeKeysToIds={},this._decorationTypeSubtypes={},this._telemetryData=i.telemetryData,this._configuration=this._register(this._createConfiguration(i.isSimpleWidget||!1,i.contextMenuId??(i.isSimpleWidget?qn.D8.SimpleEditorContext:qn.D8.EditorContext),f,g)),this._register(this._configuration.onDidChange((e=>{this._onDidChangeConfiguration.fire(e);const t=this._configuration.options;if(e.hasChanged(146)){const e=t.get(146);this._onDidLayoutChange.fire(e)}}))),this._contextKeyService=this._register(a.createScoped(this._domElement)),this._notificationService=u,this._codeEditorService=r,this._commandService=o,this._themeService=d,this._register(new ir(this,this._contextKeyService)),this._register(new sr(this,this._contextKeyService,m)),this._instantiationService=this._register(s.createChild(new Kn.a([jn.fN,this._contextKeyService]))),this._modelData=null,this._focusTracker=new nr(e,this._overflowWidgetsDomNode),this._register(this._focusTracker.onChange((()=>{this._editorWidgetFocus.setValue(this._focusTracker.hasFocus())}))),this._contentWidgets={},this._overlayWidgets={},this._glyphMarginWidgets={},_=Array.isArray(i.contributions)?i.contributions:n.dS.getEditorContributions(),this._contributions.initialize(this,_,this._instantiationService);for(const l of n.dS.getEditorActions()){if(this._actions.has(l.id)){(0,c.dz)(new Error(`Cannot have two actions with the same id ${l.id}`));continue}const e=new Ji.f(l.id,l.label,l.alias,l.metadata,l.precondition??void 0,(e=>this._instantiationService.invokeFunction((t=>Promise.resolve(l.runEditorCommand(t,this,e))))),this._contextKeyService);this._actions.set(e.id,e)}const v=()=>!this._configuration.options.get(92)&&this._configuration.options.get(36).enabled;this._register(new l.pN(this._domElement,{onDragOver:e=>{if(!v())return;const t=this.getTargetAtClientPoint(e.clientX,e.clientY);t?.position&&this.showDropIndicatorAt(t.position)},onDrop:async e=>{if(!v())return;if(this.removeDropIndicator(),!e.dataTransfer)return;const t=this.getTargetAtClientPoint(e.clientX,e.clientY);t?.position&&this._onDropIntoEditor.fire({position:t.position,event:e})},onDragLeave:()=>{this.removeDropIndicator()},onDragEnd:()=>{this.removeDropIndicator()}})),this._codeEditorService.addCodeEditor(this)}writeScreenReaderContent(e){this._modelData?.view.writeScreenReaderContent(e)}_createConfiguration(e,t,i,s){return new I(e,t,i,this._domElement,s)}getId(){return this.getEditorType()+":"+this._id}getEditorType(){return es._.ICodeEditor}dispose(){this._codeEditorService.removeCodeEditor(this),this._focusTracker.dispose(),this._actions.clear(),this._contentWidgets={},this._overlayWidgets={},this._removeDecorationTypes(),this._postDetachModelCleanup(this._detachModel()),this._onDidDispose.fire(),super.dispose()}invokeWithinContext(e){return this._instantiationService.invokeFunction(e)}updateOptions(e){this._configuration.updateOptions(e||{})}getOptions(){return this._configuration.options}getOption(e){return this._configuration.options.get(e)}getRawOptions(){return this._configuration.getRawOptions()}getOverflowWidgetsDomNode(){return this._overflowWidgetsDomNode}getConfiguredWordAtPosition(e){return this._modelData?Zi.z.getWordAtPosition(this._modelData.model,this._configuration.options.get(132),this._configuration.options.get(131),e):null}getValue(e=null){if(!this._modelData)return"";const t=!(!e||!e.preserveBOM);let i=0;return e&&e.lineEnding&&"\n"===e.lineEnding?i=1:e&&e.lineEnding&&"\r\n"===e.lineEnding&&(i=2),this._modelData.model.getValue(i,t)}setValue(e){try{if(this._beginUpdate(),!this._modelData)return;this._modelData.model.setValue(e)}finally{this._endUpdate()}}getModel(){return this._modelData?this._modelData.model:null}setModel(e=null){try{this._beginUpdate();const t=e;if(null===this._modelData&&null===t)return;if(this._modelData&&this._modelData.model===t)return;const i={oldModelUrl:this._modelData?.model.uri||null,newModelUrl:t?.uri||null};this._onWillChangeModel.fire(i);const s=this.hasTextFocus(),n=this._detachModel();this._attachModel(t),s&&this.hasModel()&&this.focus(),this._removeDecorationTypes(),this._onDidChangeModel.fire(i),this._postDetachModelCleanup(n),this._contributionsDisposable=this._contributions.onAfterModelAttached()}finally{this._endUpdate()}}_removeDecorationTypes(){if(this._decorationTypeKeysToIds={},this._decorationTypeSubtypes){for(const e in this._decorationTypeSubtypes){const t=this._decorationTypeSubtypes[e];for(const i in t)this._removeDecorationType(e+"-"+i)}this._decorationTypeSubtypes={}}}getVisibleRanges(){return this._modelData?this._modelData.viewModel.getVisibleRanges():[]}getVisibleRangesPlusViewportAboveBelow(){return this._modelData?this._modelData.viewModel.getVisibleRangesPlusViewportAboveBelow():[]}getWhitespaces(){return this._modelData?this._modelData.viewModel.viewLayout.getWhitespaces():[]}static _getVerticalOffsetAfterPosition(e,t,i,s){const n=e.model.validatePosition({lineNumber:t,column:i}),r=e.viewModel.coordinatesConverter.convertModelPositionToViewPosition(n);return e.viewModel.viewLayout.getVerticalOffsetAfterLineNumber(r.lineNumber,s)}getTopForLineNumber(e,t=!1){return this._modelData?zn._getVerticalOffsetForPosition(this._modelData,e,1,t):-1}getTopForPosition(e,t){return this._modelData?zn._getVerticalOffsetForPosition(this._modelData,e,t,!1):-1}static _getVerticalOffsetForPosition(e,t,i,s=!1){const n=e.model.validatePosition({lineNumber:t,column:i}),r=e.viewModel.coordinatesConverter.convertModelPositionToViewPosition(n);return e.viewModel.viewLayout.getVerticalOffsetForLineNumber(r.lineNumber,s)}getBottomForLineNumber(e,t=!1){if(!this._modelData)return-1;const i=this._modelData.model.getLineMaxColumn(e);return zn._getVerticalOffsetAfterPosition(this._modelData,e,i,t)}setHiddenAreas(e,t){this._modelData?.viewModel.setHiddenAreas(e.map((e=>q.Q.lift(e))),t)}getVisibleColumnFromPosition(e){if(!this._modelData)return e.column;const t=this._modelData.model.validatePosition(e),i=this._modelData.model.getOptions().tabSize;return $.A.visibleColumnFromColumn(this._modelData.model.getLineContent(t.lineNumber),t.column,i)+1}getPosition(){return this._modelData?this._modelData.viewModel.getPosition():null}setPosition(e,t="api"){if(this._modelData){if(!Y.y.isIPosition(e))throw new Error("Invalid arguments");this._modelData.viewModel.setSelections(t,[{selectionStartLineNumber:e.lineNumber,selectionStartColumn:e.column,positionLineNumber:e.lineNumber,positionColumn:e.column}])}}_sendRevealRange(e,t,i,s){if(!this._modelData)return;if(!q.Q.isIRange(e))throw new Error("Invalid arguments");const n=this._modelData.model.validateRange(e),r=this._modelData.viewModel.coordinatesConverter.convertModelRangeToViewRange(n);this._modelData.viewModel.revealRange("api",i,r,t,s)}revealLine(e,t=0){this._revealLine(e,0,t)}revealLineInCenter(e,t=0){this._revealLine(e,1,t)}revealLineInCenterIfOutsideViewport(e,t=0){this._revealLine(e,2,t)}revealLineNearTop(e,t=0){this._revealLine(e,5,t)}_revealLine(e,t,i){if("number"!==typeof e)throw new Error("Invalid arguments");this._sendRevealRange(new q.Q(e,1,e,1),t,!1,i)}revealPosition(e,t=0){this._revealPosition(e,0,!0,t)}revealPositionInCenter(e,t=0){this._revealPosition(e,1,!0,t)}revealPositionInCenterIfOutsideViewport(e,t=0){this._revealPosition(e,2,!0,t)}revealPositionNearTop(e,t=0){this._revealPosition(e,5,!0,t)}_revealPosition(e,t,i,s){if(!Y.y.isIPosition(e))throw new Error("Invalid arguments");this._sendRevealRange(new q.Q(e.lineNumber,e.column,e.lineNumber,e.column),t,i,s)}getSelection(){return this._modelData?this._modelData.viewModel.getSelection():null}getSelections(){return this._modelData?this._modelData.viewModel.getSelections():null}setSelection(e,t="api"){const i=pe.L.isISelection(e),s=q.Q.isIRange(e);if(!i&&!s)throw new Error("Invalid arguments");if(i)this._setSelectionImpl(e,t);else if(s){const i={selectionStartLineNumber:e.startLineNumber,selectionStartColumn:e.startColumn,positionLineNumber:e.endLineNumber,positionColumn:e.endColumn};this._setSelectionImpl(i,t)}}_setSelectionImpl(e,t){if(!this._modelData)return;const i=new pe.L(e.selectionStartLineNumber,e.selectionStartColumn,e.positionLineNumber,e.positionColumn);this._modelData.viewModel.setSelections(t,[i])}revealLines(e,t,i=0){this._revealLines(e,t,0,i)}revealLinesInCenter(e,t,i=0){this._revealLines(e,t,1,i)}revealLinesInCenterIfOutsideViewport(e,t,i=0){this._revealLines(e,t,2,i)}revealLinesNearTop(e,t,i=0){this._revealLines(e,t,5,i)}_revealLines(e,t,i,s){if("number"!==typeof e||"number"!==typeof t)throw new Error("Invalid arguments");this._sendRevealRange(new q.Q(e,1,t,1),i,!1,s)}revealRange(e,t=0,i=!1,s=!0){this._revealRange(e,i?1:0,s,t)}revealRangeInCenter(e,t=0){this._revealRange(e,1,!0,t)}revealRangeInCenterIfOutsideViewport(e,t=0){this._revealRange(e,2,!0,t)}revealRangeNearTop(e,t=0){this._revealRange(e,5,!0,t)}revealRangeNearTopIfOutsideViewport(e,t=0){this._revealRange(e,6,!0,t)}revealRangeAtTop(e,t=0){this._revealRange(e,3,!0,t)}_revealRange(e,t,i,s){if(!q.Q.isIRange(e))throw new Error("Invalid arguments");this._sendRevealRange(q.Q.lift(e),t,i,s)}setSelections(e,t="api",i=0){if(this._modelData){if(!e||0===e.length)throw new Error("Invalid arguments");for(let t=0,i=e.length;t0&&this._modelData.viewModel.restoreCursorState(e):this._modelData.viewModel.restoreCursorState([e]),this._contributions.restoreViewState(t.contributionsState||{});const i=this._modelData.viewModel.reduceRestoreState(t.viewState);this._modelData.view.restoreState(i)}}handleInitialized(){this._getViewModel()?.visibleLinesStabilized()}getContribution(e){return this._contributions.get(e)}getActions(){return Array.from(this._actions.values())}getSupportedActions(){let e=this.getActions();return e=e.filter((e=>e.isSupported())),e}getAction(e){return this._actions.get(e)||null}trigger(e,t,i){i=i||{};try{switch(this._beginUpdate(),t){case"compositionStart":return void this._startComposition();case"compositionEnd":return void this._endComposition(e);case"type":{const t=i;return void this._type(e,t.text||"")}case"replacePreviousChar":{const t=i;return void this._compositionType(e,t.text||"",t.replaceCharCnt||0,0,0)}case"compositionType":{const t=i;return void this._compositionType(e,t.text||"",t.replacePrevCharCnt||0,t.replaceNextCharCnt||0,t.positionDelta||0)}case"paste":{const t=i;return void this._paste(e,t.text||"",t.pasteOnNewLine||!1,t.multicursorText||null,t.mode||null,t.clipboardEvent)}case"cut":return void this._cut(e)}const s=this.getAction(t);if(s)return void Promise.resolve(s.run(i)).then(void 0,c.dz);if(!this._modelData)return;if(this._triggerEditorCommand(e,t,i))return;this._triggerCommand(t,i)}finally{this._endUpdate()}}_triggerCommand(e,t){this._commandService.executeCommand(e,t)}_startComposition(){this._modelData&&(this._modelData.viewModel.startComposition(),this._onDidCompositionStart.fire())}_endComposition(e){this._modelData&&(this._modelData.viewModel.endComposition(e),this._onDidCompositionEnd.fire())}_type(e,t){this._modelData&&0!==t.length&&("keyboard"===e&&this._onWillType.fire(t),this._modelData.viewModel.type(t,e),"keyboard"===e&&this._onDidType.fire(t))}_compositionType(e,t,i,s,n){this._modelData&&this._modelData.viewModel.compositionType(t,i,s,n,e)}_paste(e,t,i,s,n,r){if(!this._modelData)return;const o=this._modelData.viewModel,a=o.getSelection().getStartPosition();o.paste(t,i,s,e);const l=o.getSelection().getStartPosition();"keyboard"===e&&this._onDidPaste.fire({clipboardEvent:r,range:new q.Q(a.lineNumber,a.column,l.lineNumber,l.column),languageId:n})}_cut(e){this._modelData&&this._modelData.viewModel.cut(e)}_triggerEditorCommand(e,t,i){const s=n.dS.getEditorCommand(t);return!!s&&((i=i||{}).source=e,this._instantiationService.invokeFunction((e=>{Promise.resolve(s.runEditorCommand(e,this,i)).then(void 0,c.dz)})),!0)}_getViewModel(){return this._modelData?this._modelData.viewModel:null}pushUndoStop(){return!!this._modelData&&(!this._configuration.options.get(92)&&(this._modelData.model.pushStackElement(),!0))}popUndoStop(){return!!this._modelData&&(!this._configuration.options.get(92)&&(this._modelData.model.popStackElement(),!0))}executeEdits(e,t,i){if(!this._modelData)return!1;if(this._configuration.options.get(92))return!1;let s;return s=i?Array.isArray(i)?()=>i:i:()=>null,this._modelData.viewModel.executeEdits(e,t,s),!0}executeCommand(e,t){this._modelData&&this._modelData.viewModel.executeCommand(t,e)}executeCommands(e,t){this._modelData&&this._modelData.viewModel.executeCommands(t,e)}createDecorationsCollection(e){return new rr(this,e)}changeDecorations(e){return this._modelData?this._modelData.model.changeDecorations(e,this._id):null}getLineDecorations(e){return this._modelData?this._modelData.model.getLineDecorations(e,this._id,(0,L.$C)(this._configuration.options)):null}getDecorationsInRange(e){return this._modelData?this._modelData.model.getDecorationsInRange(e,this._id,(0,L.$C)(this._configuration.options)):null}deltaDecorations(e,t){return this._modelData?0===e.length&&0===t.length?e:this._modelData.model.deltaDecorations(e,t,this._id):[]}removeDecorations(e){this._modelData&&0!==e.length&&this._modelData.model.changeDecorations((t=>{t.deltaDecorations(e,[])}))}removeDecorationsByType(e){const t=this._decorationTypeKeysToIds[e];t&&this.changeDecorations((e=>e.deltaDecorations(t,[]))),this._decorationTypeKeysToIds.hasOwnProperty(e)&&delete this._decorationTypeKeysToIds[e],this._decorationTypeSubtypes.hasOwnProperty(e)&&delete this._decorationTypeSubtypes[e]}getLayoutInfo(){return this._configuration.options.get(146)}createOverviewRuler(e){return this._modelData&&this._modelData.hasRealView?this._modelData.view.createOverviewRuler(e):null}getContainerDomNode(){return this._domElement}getDomNode(){return this._modelData&&this._modelData.hasRealView?this._modelData.view.domNode.domNode:null}delegateVerticalScrollbarPointerDown(e){this._modelData&&this._modelData.hasRealView&&this._modelData.view.delegateVerticalScrollbarPointerDown(e)}delegateScrollFromMouseWheelEvent(e){this._modelData&&this._modelData.hasRealView&&this._modelData.view.delegateScrollFromMouseWheelEvent(e)}layout(e,t=!1){this._configuration.observeContainer(e),t||this.render()}focus(){this._modelData&&this._modelData.hasRealView&&this._modelData.view.focus()}hasTextFocus(){return!(!this._modelData||!this._modelData.hasRealView)&&this._modelData.view.isFocused()}hasWidgetFocus(){return this._focusTracker&&this._focusTracker.hasFocus()}addContentWidget(e){const t={widget:e,position:e.getPosition()};this._contentWidgets.hasOwnProperty(e.getId())&&console.warn("Overwriting a content widget with the same id:"+e.getId()),this._contentWidgets[e.getId()]=t,this._modelData&&this._modelData.hasRealView&&this._modelData.view.addContentWidget(t)}layoutContentWidget(e){const t=e.getId();if(this._contentWidgets.hasOwnProperty(t)){const i=this._contentWidgets[t];i.position=e.getPosition(),this._modelData&&this._modelData.hasRealView&&this._modelData.view.layoutContentWidget(i)}}removeContentWidget(e){const t=e.getId();if(this._contentWidgets.hasOwnProperty(t)){const e=this._contentWidgets[t];delete this._contentWidgets[t],this._modelData&&this._modelData.hasRealView&&this._modelData.view.removeContentWidget(e)}}addOverlayWidget(e){const t={widget:e,position:e.getPosition()};this._overlayWidgets.hasOwnProperty(e.getId())&&console.warn("Overwriting an overlay widget with the same id."),this._overlayWidgets[e.getId()]=t,this._modelData&&this._modelData.hasRealView&&this._modelData.view.addOverlayWidget(t)}layoutOverlayWidget(e){const t=e.getId();if(this._overlayWidgets.hasOwnProperty(t)){const i=this._overlayWidgets[t];i.position=e.getPosition(),this._modelData&&this._modelData.hasRealView&&this._modelData.view.layoutOverlayWidget(i)}}removeOverlayWidget(e){const t=e.getId();if(this._overlayWidgets.hasOwnProperty(t)){const e=this._overlayWidgets[t];delete this._overlayWidgets[t],this._modelData&&this._modelData.hasRealView&&this._modelData.view.removeOverlayWidget(e)}}addGlyphMarginWidget(e){const t={widget:e,position:e.getPosition()};this._glyphMarginWidgets.hasOwnProperty(e.getId())&&console.warn("Overwriting a glyph margin widget with the same id."),this._glyphMarginWidgets[e.getId()]=t,this._modelData&&this._modelData.hasRealView&&this._modelData.view.addGlyphMarginWidget(t)}layoutGlyphMarginWidget(e){const t=e.getId();if(this._glyphMarginWidgets.hasOwnProperty(t)){const i=this._glyphMarginWidgets[t];i.position=e.getPosition(),this._modelData&&this._modelData.hasRealView&&this._modelData.view.layoutGlyphMarginWidget(i)}}removeGlyphMarginWidget(e){const t=e.getId();if(this._glyphMarginWidgets.hasOwnProperty(t)){const e=this._glyphMarginWidgets[t];delete this._glyphMarginWidgets[t],this._modelData&&this._modelData.hasRealView&&this._modelData.view.removeGlyphMarginWidget(e)}}changeViewZones(e){this._modelData&&this._modelData.hasRealView&&this._modelData.view.change(e)}getTargetAtClientPoint(e,t){return this._modelData&&this._modelData.hasRealView?this._modelData.view.getTargetAtClientPoint(e,t):null}getScrolledVisiblePosition(e){if(!this._modelData||!this._modelData.hasRealView)return null;const t=this._modelData.model.validatePosition(e),i=this._configuration.options,s=i.get(146);return{top:zn._getVerticalOffsetForPosition(this._modelData,t.lineNumber,t.column)-this.getScrollTop(),left:this._modelData.view.getOffsetForColumn(t.lineNumber,t.column)+s.glyphMarginWidth+s.lineNumbersWidth+s.decorationsWidth-this.getScrollLeft(),height:i.get(67)}}getOffsetForColumn(e,t){return this._modelData&&this._modelData.hasRealView?this._modelData.view.getOffsetForColumn(e,t):-1}render(e=!1){this._modelData&&this._modelData.hasRealView&&this._modelData.viewModel.batchEvents((()=>{this._modelData.view.render(!0,e)}))}setAriaOptions(e){this._modelData&&this._modelData.hasRealView&&this._modelData.view.setAriaOptions(e)}applyFontInfo(e){(0,g.M)(e,this._configuration.options.get(50))}setBanner(e,t){this._bannerDomNode&&this._domElement.contains(this._bannerDomNode)&&this._bannerDomNode.remove(),this._bannerDomNode=e,this._configuration.setReservedHeight(e?t:0),this._bannerDomNode&&this._domElement.prepend(this._bannerDomNode)}_attachModel(e){if(!e)return void(this._modelData=null);const t=[];this._domElement.setAttribute("data-mode-id",e.getLanguageId()),this._configuration.setIsDominatedByLongLines(e.isDominatedByLongLines()),this._configuration.setModelLineCount(e.getLineCount());const i=e.onBeforeAttached(),s=new Fn(this._id,this._configuration,e,Ki.create(l.zk(this._domElement)),os.create(this._configuration.options),(e=>l.PG(l.zk(this._domElement),e)),this.languageConfigurationService,this._themeService,i,{batchChanges:e=>{try{return this._beginUpdate(),e()}finally{this._endUpdate()}}});t.push(e.onWillDispose((()=>this.setModel(null)))),t.push(s.onEvent((t=>{switch(t.kind){case 0:this._onDidContentSizeChange.fire(t);break;case 1:this._editorTextFocus.setValue(t.hasFocus);break;case 2:this._onDidScrollChange.fire(t);break;case 3:this._onDidChangeViewZones.fire();break;case 4:this._onDidChangeHiddenAreas.fire();break;case 5:this._onDidAttemptReadOnlyEdit.fire();break;case 6:{if(t.reachedMaxCursorCount){const e=this.getOption(80),t=Le.kg("cursors.maximum","The number of cursors has been limited to {0}. Consider using [find and replace](https://code.visualstudio.com/docs/editor/codebasics#_find-and-replace) for larger changes or increase the editor multi cursor limit setting.",e);this._notificationService.prompt(Yn.AI.Warning,t,[{label:"Find and Replace",run:()=>{this._commandService.executeCommand("editor.action.startFindReplaceAction")}},{label:Le.kg("goToSetting","Increase Multi Cursor Limit"),run:()=>{this._commandService.executeCommand("workbench.action.openSettings2",{query:"editor.multiCursorLimit"})}}])}const e=[];for(let n=0,r=t.selections.length;n{this._paste("keyboard",e,t,i,s)},type:e=>{this._type("keyboard",e)},compositionType:(e,t,i,s)=>{this._compositionType("keyboard",e,t,i,s)},startComposition:()=>{this._startComposition()},endComposition:()=>{this._endComposition("keyboard")},cut:()=>{this._cut("keyboard")}}:{paste:(e,t,i,s)=>{const n={text:e,pasteOnNewLine:t,multicursorText:i,mode:s};this._commandService.executeCommand("paste",n)},type:e=>{const t={text:e};this._commandService.executeCommand("type",t)},compositionType:(e,t,i,s)=>{if(i||s){const n={text:e,replacePrevCharCnt:t,replaceNextCharCnt:i,positionDelta:s};this._commandService.executeCommand("compositionType",n)}else{const i={text:e,replaceCharCnt:t};this._commandService.executeCommand("replacePreviousChar",i)}},startComposition:()=>{this._commandService.executeCommand("compositionStart",{})},endComposition:()=>{this._commandService.executeCommand("compositionEnd",{})},cut:()=>{this._commandService.executeCommand("cut",{})}};const i=new st(e.coordinatesConverter);i.onKeyDown=e=>this._onKeyDown.fire(e),i.onKeyUp=e=>this._onKeyUp.fire(e),i.onContextMenu=e=>this._onContextMenu.fire(e),i.onMouseMove=e=>this._onMouseMove.fire(e),i.onMouseLeave=e=>this._onMouseLeave.fire(e),i.onMouseDown=e=>this._onMouseDown.fire(e),i.onMouseUp=e=>this._onMouseUp.fire(e),i.onMouseDrag=e=>this._onMouseDrag.fire(e),i.onMouseDrop=e=>this._onMouseDrop.fire(e),i.onMouseDropCanceled=e=>this._onMouseDropCanceled.fire(e),i.onMouseWheel=e=>this._onMouseWheel.fire(e);return[new Pi(t,this._configuration,this._themeService.getColorTheme(),e,i,this._overflowWidgetsDomNode,this._instantiationService),!0]}_postDetachModelCleanup(e){e?.removeAllDecorationsWithOwnerId(this._id)}_detachModel(){if(this._contributionsDisposable?.dispose(),this._contributionsDisposable=void 0,!this._modelData)return null;const e=this._modelData.model,t=this._modelData.hasRealView?this._modelData.view.domNode.domNode:null;return this._modelData.dispose(),this._modelData=null,this._domElement.removeAttribute("data-mode-id"),t&&this._domElement.contains(t)&&t.remove(),this._bannerDomNode&&this._domElement.contains(this._bannerDomNode)&&this._bannerDomNode.remove(),e}_removeDecorationType(e){this._codeEditorService.removeDecorationType(e)}hasModel(){return null!==this._modelData}showDropIndicatorAt(e){const t=[{range:new q.Q(e.lineNumber,e.column,e.lineNumber,e.column),options:zn.dropIntoEditorDecorationOptions}];this._dropIntoEditorDecorations.set(t),this.revealPosition(e,1)}removeDropIndicator(){this._dropIntoEditorDecorations.clear()}setContextValue(e,t){this._contextKeyService.createKey(e,t)}_beginUpdate(){this._updateCounter++,1===this._updateCounter&&this._onBeginUpdate.fire()}_endUpdate(){this._updateCounter--,0===this._updateCounter&&this._onEndUpdate.fire()}};Xn=zn=$n([Qn(3,He._Y),Qn(4,U.T),Qn(5,Gn.d),Qn(6,jn.fN),Qn(7,ke.Gy),Qn(8,Yn.Ot),Qn(9,x.j),Qn(10,is.JZ),Qn(11,ns.ILanguageFeaturesService)],Xn);let Zn=0;class Jn{constructor(e,t,i,s,n,r){this.model=e,this.viewModel=t,this.view=i,this.hasRealView=s,this.listenersToRemove=n,this.attachedView=r}dispose(){(0,d.AS)(this.listenersToRemove),this.model.onBeforeDetached(this.attachedView),this.hasRealView&&this.view.dispose(),this.viewModel.dispose()}}class er extends d.jG{constructor(e){super(),this._emitterOptions=e,this._onDidChangeToTrue=this._register(new h.vl(this._emitterOptions)),this.onDidChangeToTrue=this._onDidChangeToTrue.event,this._onDidChangeToFalse=this._register(new h.vl(this._emitterOptions)),this.onDidChangeToFalse=this._onDidChangeToFalse.event,this._value=0}setValue(e){const t=e?2:1;this._value!==t&&(this._value=t,2===this._value?this._onDidChangeToTrue.fire():1===this._value&&this._onDidChangeToFalse.fire())}}class tr extends h.vl{constructor(e,t){super({deliveryQueue:t}),this._contributions=e}fire(e){this._contributions.onBeforeInteractionEvent(),super.fire(e)}}class ir extends d.jG{constructor(e,t){super(),this._editor=e,t.createKey("editorId",e.getId()),this._editorSimpleInput=ts.R.editorSimpleInput.bindTo(t),this._editorFocus=ts.R.focus.bindTo(t),this._textInputFocus=ts.R.textInputFocus.bindTo(t),this._editorTextFocus=ts.R.editorTextFocus.bindTo(t),this._tabMovesFocus=ts.R.tabMovesFocus.bindTo(t),this._editorReadonly=ts.R.readOnly.bindTo(t),this._inDiffEditor=ts.R.inDiffEditor.bindTo(t),this._editorColumnSelection=ts.R.columnSelection.bindTo(t),this._hasMultipleSelections=ts.R.hasMultipleSelections.bindTo(t),this._hasNonEmptySelection=ts.R.hasNonEmptySelection.bindTo(t),this._canUndo=ts.R.canUndo.bindTo(t),this._canRedo=ts.R.canRedo.bindTo(t),this._register(this._editor.onDidChangeConfiguration((()=>this._updateFromConfig()))),this._register(this._editor.onDidChangeCursorSelection((()=>this._updateFromSelection()))),this._register(this._editor.onDidFocusEditorWidget((()=>this._updateFromFocus()))),this._register(this._editor.onDidBlurEditorWidget((()=>this._updateFromFocus()))),this._register(this._editor.onDidFocusEditorText((()=>this._updateFromFocus()))),this._register(this._editor.onDidBlurEditorText((()=>this._updateFromFocus()))),this._register(this._editor.onDidChangeModel((()=>this._updateFromModel()))),this._register(this._editor.onDidChangeConfiguration((()=>this._updateFromModel()))),this._register(w.M.onDidChangeTabFocus((e=>this._tabMovesFocus.set(e)))),this._updateFromConfig(),this._updateFromSelection(),this._updateFromFocus(),this._updateFromModel(),this._editorSimpleInput.set(this._editor.isSimpleWidget)}_updateFromConfig(){const e=this._editor.getOptions();this._tabMovesFocus.set(w.M.getTabFocusMode()),this._editorReadonly.set(e.get(92)),this._inDiffEditor.set(e.get(61)),this._editorColumnSelection.set(e.get(22))}_updateFromSelection(){const e=this._editor.getSelections();e?(this._hasMultipleSelections.set(e.length>1),this._hasNonEmptySelection.set(e.some((e=>!e.isEmpty())))):(this._hasMultipleSelections.reset(),this._hasNonEmptySelection.reset())}_updateFromFocus(){this._editorFocus.set(this._editor.hasWidgetFocus()&&!this._editor.isSimpleWidget),this._editorTextFocus.set(this._editor.hasTextFocus()&&!this._editor.isSimpleWidget),this._textInputFocus.set(this._editor.hasTextFocus())}_updateFromModel(){const e=this._editor.getModel();this._canUndo.set(Boolean(e&&e.canUndo())),this._canRedo.set(Boolean(e&&e.canRedo()))}}class sr extends d.jG{constructor(e,t,i){super(),this._editor=e,this._contextKeyService=t,this._languageFeaturesService=i,this._langId=ts.R.languageId.bindTo(t),this._hasCompletionItemProvider=ts.R.hasCompletionItemProvider.bindTo(t),this._hasCodeActionsProvider=ts.R.hasCodeActionsProvider.bindTo(t),this._hasCodeLensProvider=ts.R.hasCodeLensProvider.bindTo(t),this._hasDefinitionProvider=ts.R.hasDefinitionProvider.bindTo(t),this._hasDeclarationProvider=ts.R.hasDeclarationProvider.bindTo(t),this._hasImplementationProvider=ts.R.hasImplementationProvider.bindTo(t),this._hasTypeDefinitionProvider=ts.R.hasTypeDefinitionProvider.bindTo(t),this._hasHoverProvider=ts.R.hasHoverProvider.bindTo(t),this._hasDocumentHighlightProvider=ts.R.hasDocumentHighlightProvider.bindTo(t),this._hasDocumentSymbolProvider=ts.R.hasDocumentSymbolProvider.bindTo(t),this._hasReferenceProvider=ts.R.hasReferenceProvider.bindTo(t),this._hasRenameProvider=ts.R.hasRenameProvider.bindTo(t),this._hasSignatureHelpProvider=ts.R.hasSignatureHelpProvider.bindTo(t),this._hasInlayHintsProvider=ts.R.hasInlayHintsProvider.bindTo(t),this._hasDocumentFormattingProvider=ts.R.hasDocumentFormattingProvider.bindTo(t),this._hasDocumentSelectionFormattingProvider=ts.R.hasDocumentSelectionFormattingProvider.bindTo(t),this._hasMultipleDocumentFormattingProvider=ts.R.hasMultipleDocumentFormattingProvider.bindTo(t),this._hasMultipleDocumentSelectionFormattingProvider=ts.R.hasMultipleDocumentSelectionFormattingProvider.bindTo(t),this._isInEmbeddedEditor=ts.R.isInEmbeddedEditor.bindTo(t);const s=()=>this._update();this._register(e.onDidChangeModel(s)),this._register(e.onDidChangeModelLanguage(s)),this._register(i.completionProvider.onDidChange(s)),this._register(i.codeActionProvider.onDidChange(s)),this._register(i.codeLensProvider.onDidChange(s)),this._register(i.definitionProvider.onDidChange(s)),this._register(i.declarationProvider.onDidChange(s)),this._register(i.implementationProvider.onDidChange(s)),this._register(i.typeDefinitionProvider.onDidChange(s)),this._register(i.hoverProvider.onDidChange(s)),this._register(i.documentHighlightProvider.onDidChange(s)),this._register(i.documentSymbolProvider.onDidChange(s)),this._register(i.referenceProvider.onDidChange(s)),this._register(i.renameProvider.onDidChange(s)),this._register(i.documentFormattingEditProvider.onDidChange(s)),this._register(i.documentRangeFormattingEditProvider.onDidChange(s)),this._register(i.signatureHelpProvider.onDidChange(s)),this._register(i.inlayHintsProvider.onDidChange(s)),s()}dispose(){super.dispose()}reset(){this._contextKeyService.bufferChangeEvents((()=>{this._langId.reset(),this._hasCompletionItemProvider.reset(),this._hasCodeActionsProvider.reset(),this._hasCodeLensProvider.reset(),this._hasDefinitionProvider.reset(),this._hasDeclarationProvider.reset(),this._hasImplementationProvider.reset(),this._hasTypeDefinitionProvider.reset(),this._hasHoverProvider.reset(),this._hasDocumentHighlightProvider.reset(),this._hasDocumentSymbolProvider.reset(),this._hasReferenceProvider.reset(),this._hasRenameProvider.reset(),this._hasDocumentFormattingProvider.reset(),this._hasDocumentSelectionFormattingProvider.reset(),this._hasSignatureHelpProvider.reset(),this._isInEmbeddedEditor.reset()}))}_update(){const e=this._editor.getModel();e?this._contextKeyService.bufferChangeEvents((()=>{this._langId.set(e.getLanguageId()),this._hasCompletionItemProvider.set(this._languageFeaturesService.completionProvider.has(e)),this._hasCodeActionsProvider.set(this._languageFeaturesService.codeActionProvider.has(e)),this._hasCodeLensProvider.set(this._languageFeaturesService.codeLensProvider.has(e)),this._hasDefinitionProvider.set(this._languageFeaturesService.definitionProvider.has(e)),this._hasDeclarationProvider.set(this._languageFeaturesService.declarationProvider.has(e)),this._hasImplementationProvider.set(this._languageFeaturesService.implementationProvider.has(e)),this._hasTypeDefinitionProvider.set(this._languageFeaturesService.typeDefinitionProvider.has(e)),this._hasHoverProvider.set(this._languageFeaturesService.hoverProvider.has(e)),this._hasDocumentHighlightProvider.set(this._languageFeaturesService.documentHighlightProvider.has(e)),this._hasDocumentSymbolProvider.set(this._languageFeaturesService.documentSymbolProvider.has(e)),this._hasReferenceProvider.set(this._languageFeaturesService.referenceProvider.has(e)),this._hasRenameProvider.set(this._languageFeaturesService.renameProvider.has(e)),this._hasSignatureHelpProvider.set(this._languageFeaturesService.signatureHelpProvider.has(e)),this._hasInlayHintsProvider.set(this._languageFeaturesService.inlayHintsProvider.has(e)),this._hasDocumentFormattingProvider.set(this._languageFeaturesService.documentFormattingEditProvider.has(e)||this._languageFeaturesService.documentRangeFormattingEditProvider.has(e)),this._hasDocumentSelectionFormattingProvider.set(this._languageFeaturesService.documentRangeFormattingEditProvider.has(e)),this._hasMultipleDocumentFormattingProvider.set(this._languageFeaturesService.documentFormattingEditProvider.all(e).length+this._languageFeaturesService.documentRangeFormattingEditProvider.all(e).length>1),this._hasMultipleDocumentSelectionFormattingProvider.set(this._languageFeaturesService.documentRangeFormattingEditProvider.all(e).length>1),this._isInEmbeddedEditor.set(e.uri.scheme===u.ny.walkThroughSnippet||e.uri.scheme===u.ny.vscodeChatCodeBlock)})):this.reset()}}class nr extends d.jG{constructor(e,t){super(),this._onChange=this._register(new h.vl),this.onChange=this._onChange.event,this._hadFocus=void 0,this._hasDomElementFocus=!1,this._domFocusTracker=this._register(l.w5(e)),this._overflowWidgetsDomNodeHasFocus=!1,this._register(this._domFocusTracker.onDidFocus((()=>{this._hasDomElementFocus=!0,this._update()}))),this._register(this._domFocusTracker.onDidBlur((()=>{this._hasDomElementFocus=!1,this._update()}))),t&&(this._overflowWidgetsDomNode=this._register(l.w5(t)),this._register(this._overflowWidgetsDomNode.onDidFocus((()=>{this._overflowWidgetsDomNodeHasFocus=!0,this._update()}))),this._register(this._overflowWidgetsDomNode.onDidBlur((()=>{this._overflowWidgetsDomNodeHasFocus=!1,this._update()}))))}_update(){const e=this._hasDomElementFocus||this._overflowWidgetsDomNodeHasFocus;this._hadFocus!==e&&(this._hadFocus=e,this._onChange.fire(void 0))}hasFocus(){return this._hadFocus??!1}}class rr{get length(){return this._decorationIds.length}constructor(e,t){this._editor=e,this._decorationIds=[],this._isChangingDecorations=!1,Array.isArray(t)&&t.length>0&&this.set(t)}onDidChange(e,t,i){return this._editor.onDidChangeModelDecorations((i=>{this._isChangingDecorations||e.call(t,i)}),i)}getRange(e){return this._editor.hasModel()?e>=this._decorationIds.length?null:this._editor.getModel().getDecorationRange(this._decorationIds[e]):null}getRanges(){if(!this._editor.hasModel())return[];const e=this._editor.getModel(),t=[];for(const i of this._decorationIds){const s=e.getDecorationRange(i);s&&t.push(s)}return t}has(e){return this._decorationIds.includes(e.id)}clear(){0!==this._decorationIds.length&&this.set([])}set(e){try{this._isChangingDecorations=!0,this._editor.changeDecorations((t=>{this._decorationIds=t.deltaDecorations(this._decorationIds,e)}))}finally{this._isChangingDecorations=!1}return this._decorationIds}append(e){let t=[];try{this._isChangingDecorations=!0,this._editor.changeDecorations((i=>{t=i.deltaDecorations([],e),this._decorationIds=this._decorationIds.concat(t)}))}finally{this._isChangingDecorations=!1}return t}}const or=encodeURIComponent("");function lr(e){return or+encodeURIComponent(e.toString())+ar}const cr=encodeURIComponent('');(0,ke.zy)(((e,t)=>{const i=e.getColor(zt.Rbi);i&&t.addRule(`.monaco-editor .squiggly-error { background: url("data:image/svg+xml,${lr(i)}") repeat-x bottom left; }`);const s=e.getColor(zt.Hng);s&&t.addRule(`.monaco-editor .squiggly-warning { background: url("data:image/svg+xml,${lr(s)}") repeat-x bottom left; }`);const n=e.getColor(zt.pOz);n&&t.addRule(`.monaco-editor .squiggly-info { background: url("data:image/svg+xml,${lr(n)}") repeat-x bottom left; }`);const r=e.getColor(zt.i61);r&&t.addRule(`.monaco-editor .squiggly-hint { background: url("data:image/svg+xml,${function(e){return cr+encodeURIComponent(e.toString())+hr}(r)}") no-repeat bottom left; }`);const o=e.getColor(Ae.yw);o&&t.addRule(`.monaco-editor.showUnused .squiggly-inline-unnecessary { opacity: ${o.rgba.a}; }`)}))},29163:(e,t,i)=>{"use strict";i.d(t,{t:()=>f});var s=i(10146),n=i(80301),r=i(52555),o=i(17469),a=i(56942),l=i(253),c=i(50091),h=i(32848),d=i(63591),u=i(58591),g=i(47612),p=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},m=function(e,t){return function(i,s){t(i,s,e)}};let f=class extends r.x{constructor(e,t,i,s,n,r,o,a,l,c,h,d,u){super(e,{...s.getRawOptions(),overflowWidgetsDomNode:s.getOverflowWidgetsDomNode()},i,n,r,o,a,l,c,h,d,u),this._parentEditor=s,this._overwriteOptions=t,super.updateOptions(this._overwriteOptions),this._register(s.onDidChangeConfiguration((e=>this._onParentConfigurationChanged(e))))}getParentEditor(){return this._parentEditor}_onParentConfigurationChanged(e){super.updateOptions(this._parentEditor.getRawOptions()),super.updateOptions(this._overwriteOptions)}updateOptions(e){s.co(this._overwriteOptions,e,!0),super.updateOptions(this._overwriteOptions)}};f=p([m(4,d._Y),m(5,n.T),m(6,c.d),m(7,h.fN),m(8,g.Gy),m(9,u.Ot),m(10,l.j),m(11,o.JZ),m(12,a.ILanguageFeaturesService)],f)},20961:(e,t,i)=>{"use strict";var s=i(10350),n=i(8597),r=i(31450),o=i(80301),a=i(4360),l=i(60002),c=i(78209),h=i(27195),d=i(84001),u=i(32848);i(10691);class g extends h.L{constructor(){super({id:"diffEditor.toggleCollapseUnchangedRegions",title:(0,c.aS)("toggleCollapseUnchangedRegions","Toggle Collapse Unchanged Regions"),icon:s.W.map,toggled:u.M$.has("config.diffEditor.hideUnchangedRegions.enabled"),precondition:u.M$.has("isInDiffEditor"),menu:{when:u.M$.has("isInDiffEditor"),id:h.D8.EditorTitle,order:22,group:"navigation"}})}run(e,...t){const i=e.get(d.pG),s=!i.getValue("diffEditor.hideUnchangedRegions.enabled");i.updateValue("diffEditor.hideUnchangedRegions.enabled",s)}}class p extends h.L{constructor(){super({id:"diffEditor.toggleShowMovedCodeBlocks",title:(0,c.aS)("toggleShowMovedCodeBlocks","Toggle Show Moved Code Blocks"),precondition:u.M$.has("isInDiffEditor")})}run(e,...t){const i=e.get(d.pG),s=!i.getValue("diffEditor.experimental.showMoves");i.updateValue("diffEditor.experimental.showMoves",s)}}class m extends h.L{constructor(){super({id:"diffEditor.toggleUseInlineViewWhenSpaceIsLimited",title:(0,c.aS)("toggleUseInlineViewWhenSpaceIsLimited","Toggle Use Inline View When Space Is Limited"),precondition:u.M$.has("isInDiffEditor")})}run(e,...t){const i=e.get(d.pG),s=!i.getValue("diffEditor.useInlineViewWhenSpaceIsLimited");i.updateValue("diffEditor.useInlineViewWhenSpaceIsLimited",s)}}const f=(0,c.aS)("diffEditor","Diff Editor");class _ extends r.qO{constructor(){super({id:"diffEditor.switchSide",title:(0,c.aS)("switchSide","Switch Side"),icon:s.W.arrowSwap,precondition:u.M$.has("isInDiffEditor"),f1:!0,category:f})}runEditorCommand(e,t,i){const s=L(e);if(s instanceof a.T){if(i&&i.dryRun)return{destinationSelection:s.mapToOtherSide().destinationSelection};s.switchSide()}}}class v extends r.qO{constructor(){super({id:"diffEditor.exitCompareMove",title:(0,c.aS)("exitCompareMove","Exit Compare Move"),icon:s.W.close,precondition:l.R.comparingMovedCode,f1:!1,category:f,keybinding:{weight:1e4,primary:9}})}runEditorCommand(e,t,...i){const s=L(e);s instanceof a.T&&s.exitCompareMove()}}class C extends r.qO{constructor(){super({id:"diffEditor.collapseAllUnchangedRegions",title:(0,c.aS)("collapseAllUnchangedRegions","Collapse All Unchanged Regions"),icon:s.W.fold,precondition:u.M$.has("isInDiffEditor"),f1:!0,category:f})}runEditorCommand(e,t,...i){const s=L(e);s instanceof a.T&&s.collapseAllUnchangedRegions()}}class b extends r.qO{constructor(){super({id:"diffEditor.showAllUnchangedRegions",title:(0,c.aS)("showAllUnchangedRegions","Show All Unchanged Regions"),icon:s.W.unfold,precondition:u.M$.has("isInDiffEditor"),f1:!0,category:f})}runEditorCommand(e,t,...i){const s=L(e);s instanceof a.T&&s.showAllUnchangedRegions()}}class E extends h.L{constructor(){super({id:"diffEditor.revert",title:(0,c.aS)("revert","Revert"),f1:!1,category:f})}run(e,t){const i=function(e,t,i){const s=e.get(o.T);return s.listDiffEditors().find((e=>{const s=e.getModifiedEditor(),n=e.getOriginalEditor();return s&&s.getModel()?.uri.toString()===i.toString()&&n&&n.getModel()?.uri.toString()===t.toString()}))||null}(e,t.originalUri,t.modifiedUri);i instanceof a.T&&i.revertRangeMappings(t.mapping.innerChanges??[])}}const S=(0,c.aS)("accessibleDiffViewer","Accessible Diff Viewer");class y extends h.L{static{this.id="editor.action.accessibleDiffViewer.next"}constructor(){super({id:y.id,title:(0,c.aS)("editor.action.accessibleDiffViewer.next","Go to Next Difference"),category:S,precondition:u.M$.has("isInDiffEditor"),keybinding:{primary:65,weight:100},f1:!0})}run(e){const t=L(e);t?.accessibleDiffViewerNext()}}class w extends h.L{static{this.id="editor.action.accessibleDiffViewer.prev"}constructor(){super({id:w.id,title:(0,c.aS)("editor.action.accessibleDiffViewer.prev","Go to Previous Difference"),category:S,precondition:u.M$.has("isInDiffEditor"),keybinding:{primary:1089,weight:100},f1:!0})}run(e){const t=L(e);t?.accessibleDiffViewerPrev()}}function L(e){const t=e.get(o.T).listDiffEditors(),i=(0,n.bq)();if(i)for(const s of t){if(R(s.getContainerDomNode(),i))return s}return null}function R(e,t){let i=t;for(;i;){if(i===e)return!0;i=i.parentElement}return!1}var T=i(50091);(0,h.ug)(g),(0,h.ug)(p),(0,h.ug)(m),h.ZG.appendMenuItem(h.D8.EditorTitle,{command:{id:(new m).desc.id,title:(0,c.kg)("useInlineViewWhenSpaceIsLimited","Use Inline View When Space Is Limited"),toggled:u.M$.has("config.diffEditor.useInlineViewWhenSpaceIsLimited"),precondition:u.M$.has("isInDiffEditor")},order:11,group:"1_diff",when:u.M$.and(l.R.diffEditorRenderSideBySideInlineBreakpointReached,u.M$.has("isInDiffEditor"))}),h.ZG.appendMenuItem(h.D8.EditorTitle,{command:{id:(new p).desc.id,title:(0,c.kg)("showMoves","Show Moved Code Blocks"),icon:s.W.move,toggled:u.f1.create("config.diffEditor.experimental.showMoves",!0),precondition:u.M$.has("isInDiffEditor")},order:10,group:"1_diff",when:u.M$.has("isInDiffEditor")}),(0,h.ug)(E);for(const x of[{icon:s.W.arrowRight,key:l.R.diffEditorInlineMode.toNegated()},{icon:s.W.discard,key:l.R.diffEditorInlineMode}])h.ZG.appendMenuItem(h.D8.DiffEditorHunkToolbar,{command:{id:(new E).desc.id,title:(0,c.kg)("revertHunk","Revert Block"),icon:x.icon},when:u.M$.and(l.R.diffEditorModifiedWritable,x.key),order:5,group:"primary"}),h.ZG.appendMenuItem(h.D8.DiffEditorSelectionToolbar,{command:{id:(new E).desc.id,title:(0,c.kg)("revertSelection","Revert Selection"),icon:x.icon},when:u.M$.and(l.R.diffEditorModifiedWritable,x.key),order:5,group:"primary"});(0,h.ug)(_),(0,h.ug)(v),(0,h.ug)(C),(0,h.ug)(b),h.ZG.appendMenuItem(h.D8.EditorTitle,{command:{id:y.id,title:(0,c.kg)("Open Accessible Diff Viewer","Open Accessible Diff Viewer"),precondition:u.M$.has("isInDiffEditor")},order:10,group:"2_diff",when:u.M$.and(l.R.accessibleDiffViewerVisible.negate(),u.M$.has("isInDiffEditor"))}),T.w.registerCommandAlias("editor.action.diffReview.next",y.id),(0,h.ug)(y),T.w.registerCommandAlias("editor.action.diffReview.prev",w.id),(0,h.ug)(w)},4360:(e,t,i)=>{"use strict";i.d(t,{T:()=>Bt});var s=i(8597),n=i(46041),r=i(64383),o=i(41234),a=i(5662),l=i(31308),c=i(87958),h=i(31450),d=i(80301),u=i(55190),g=i(52555),p=i(80789),m=i(11799),f=i(31295),_=i(36921),v=i(25890),C=i(10350),b=i(25689),E=i(73157),S=i(92368),y=i(87908),w=i(86571),L=i(74444),R=i(83069),T=i(36677),x=i(87723),k=i(10154),A=i(87469),N=i(35600),I=i(92896),O=i(78209),D=i(87213),M=i(63591),P=i(61394),F=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},U=function(e,t){return function(i,s){t(i,s,e)}};const H=(0,P.pU)("diff-review-insert",C.W.add,(0,O.kg)("accessibleDiffViewerInsertIcon","Icon for 'Insert' in accessible diff viewer.")),B=(0,P.pU)("diff-review-remove",C.W.remove,(0,O.kg)("accessibleDiffViewerRemoveIcon","Icon for 'Remove' in accessible diff viewer.")),W=(0,P.pU)("diff-review-close",C.W.close,(0,O.kg)("accessibleDiffViewerCloseIcon","Icon for 'Close' in accessible diff viewer."));let V=class extends a.jG{static{this._ttPolicy=(0,p.H)("diffReview",{createHTML:e=>e})}constructor(e,t,i,s,n,r,o,a,c){super(),this._parentNode=e,this._visible=t,this._setVisible=i,this._canClose=s,this._width=n,this._height=r,this._diffs=o,this._models=a,this._instantiationService=c,this._state=(0,l.rm)(this,((e,t)=>{const i=this._visible.read(e);if(this._parentNode.style.visibility=i?"visible":"hidden",!i)return null;const s=t.add(this._instantiationService.createInstance(z,this._diffs,this._models,this._setVisible,this._canClose));return{model:s,view:t.add(this._instantiationService.createInstance(X,this._parentNode,s,this._width,this._height,this._models))}})).recomputeInitiallyAndOnChange(this._store)}next(){(0,l.Rn)((e=>{const t=this._visible.get();this._setVisible(!0,e),t&&this._state.get().model.nextGroup(e)}))}prev(){(0,l.Rn)((e=>{this._setVisible(!0,e),this._state.get().model.previousGroup(e)}))}close(){(0,l.Rn)((e=>{this._setVisible(!1,e)}))}};V=F([U(8,M._Y)],V);let z=class extends a.jG{constructor(e,t,i,s,n){super(),this._diffs=e,this._models=t,this._setVisible=i,this.canClose=s,this._accessibilitySignalService=n,this._groups=(0,l.FY)(this,[]),this._currentGroupIdx=(0,l.FY)(this,0),this._currentElementIdx=(0,l.FY)(this,0),this.groups=this._groups,this.currentGroup=this._currentGroupIdx.map(((e,t)=>this._groups.read(t)[e])),this.currentGroupIndex=this._currentGroupIdx,this.currentElement=this._currentElementIdx.map(((e,t)=>this.currentGroup.read(t)?.lines[e])),this._register((0,l.fm)((e=>{const t=this._diffs.read(e);if(!t)return void this._groups.set([],void 0);const i=function(e,t,i){const s=[];for(const n of(0,v.n)(e,((e,t)=>t.modified.startLineNumber-e.modified.endLineNumberExclusive<2*G))){const e=[];e.push(new Y);const r=new w.M(Math.max(1,n[0].original.startLineNumber-G),Math.min(n[n.length-1].original.endLineNumberExclusive+G,t+1)),o=new w.M(Math.max(1,n[0].modified.startLineNumber-G),Math.min(n[n.length-1].modified.endLineNumberExclusive+G,i+1));(0,v.pN)(n,((t,i)=>{const s=new w.M(t?t.original.endLineNumberExclusive:r.startLineNumber,i?i.original.startLineNumber:r.endLineNumberExclusive),n=new w.M(t?t.modified.endLineNumberExclusive:o.startLineNumber,i?i.modified.startLineNumber:o.endLineNumberExclusive);s.forEach((t=>{e.push(new Q(t,n.startLineNumber+(t-s.startLineNumber)))})),i&&(i.original.forEach((t=>{e.push(new q(i,t))})),i.modified.forEach((t=>{e.push(new $(i,t))})))}));const a=n[0].modified.join(n[n.length-1].modified),l=n[0].original.join(n[n.length-1].original);s.push(new K(new x.WL(a,l),e))}return s}(t,this._models.getOriginalModel().getLineCount(),this._models.getModifiedModel().getLineCount());(0,l.Rn)((e=>{const t=this._models.getModifiedPosition();if(t){const s=i.findIndex((e=>t?.lineNumber{const t=this.currentElement.read(e);t?.type===j.Deleted?this._accessibilitySignalService.playSignal(D.Rh.diffLineDeleted,{source:"accessibleDiffViewer.currentElementChanged"}):t?.type===j.Added&&this._accessibilitySignalService.playSignal(D.Rh.diffLineInserted,{source:"accessibleDiffViewer.currentElementChanged"})}))),this._register((0,l.fm)((e=>{const t=this.currentElement.read(e);if(t&&t.type!==j.Header){const e=t.modifiedLineNumber??t.diff.modified.startLineNumber;this._models.modifiedSetSelection(T.Q.fromPositions(new R.y(e,1)))}})))}_goToGroupDelta(e,t){const i=this.groups.get();!i||i.length<=1||(0,l.PO)(t,(t=>{this._currentGroupIdx.set(L.L.ofLength(i.length).clipCyclic(this._currentGroupIdx.get()+e),t),this._currentElementIdx.set(0,t)}))}nextGroup(e){this._goToGroupDelta(1,e)}previousGroup(e){this._goToGroupDelta(-1,e)}_goToLineDelta(e){const t=this.currentGroup.get();!t||t.lines.length<=1||(0,l.Rn)((i=>{this._currentElementIdx.set(L.L.ofLength(t.lines.length).clip(this._currentElementIdx.get()+e),i)}))}goToNextLine(){this._goToLineDelta(1)}goToPreviousLine(){this._goToLineDelta(-1)}goToLine(e){const t=this.currentGroup.get();if(!t)return;const i=t.lines.indexOf(e);-1!==i&&(0,l.Rn)((e=>{this._currentElementIdx.set(i,e)}))}revealCurrentElementInEditor(){if(!this.canClose.get())return;this._setVisible(!1,void 0);const e=this.currentElement.get();e&&(e.type===j.Deleted?this._models.originalReveal(T.Q.fromPositions(new R.y(e.originalLineNumber,1))):this._models.modifiedReveal(e.type!==j.Header?T.Q.fromPositions(new R.y(e.modifiedLineNumber,1)):void 0))}close(){this.canClose.get()&&(this._setVisible(!1,void 0),this._models.modifiedFocus())}};z=F([U(4,D.Nt)],z);const G=3;var j;!function(e){e[e.Header=0]="Header",e[e.Unchanged=1]="Unchanged",e[e.Deleted=2]="Deleted",e[e.Added=3]="Added"}(j||(j={}));class K{constructor(e,t){this.range=e,this.lines=t}}class Y{constructor(){this.type=j.Header}}class q{constructor(e,t){this.diff=e,this.originalLineNumber=t,this.type=j.Deleted,this.modifiedLineNumber=void 0}}class ${constructor(e,t){this.diff=e,this.modifiedLineNumber=t,this.type=j.Added,this.originalLineNumber=void 0}}class Q{constructor(e,t){this.originalLineNumber=e,this.modifiedLineNumber=t,this.type=j.Unchanged}}let X=class extends a.jG{constructor(e,t,i,n,r,o){super(),this._element=e,this._model=t,this._width=i,this._height=n,this._models=r,this._languageService=o,this.domNode=this._element,this.domNode.className="monaco-component diff-review monaco-editor-background";const c=document.createElement("div");c.className="diff-review-actions",this._actionBar=this._register(new m.E(c)),this._register((0,l.fm)((e=>{this._actionBar.clear(),this._model.canClose.read(e)&&this._actionBar.push(new _.rc("diffreview.close",(0,O.kg)("label.close","Close"),"close-diff-review "+b.L.asClassName(W),!0,(async()=>t.close())),{label:!1,icon:!0})}))),this._content=document.createElement("div"),this._content.className="diff-review-content",this._content.setAttribute("role","code"),this._scrollbar=this._register(new f.MU(this._content,{})),(0,s.Ln)(this.domNode,this._scrollbar.getDomNode(),c),this._register((0,l.fm)((e=>{this._height.read(e),this._width.read(e),this._scrollbar.scanDomNode()}))),this._register((0,a.s)((()=>{(0,s.Ln)(this.domNode)}))),this._register((0,S.AV)(this.domNode,{width:this._width,height:this._height})),this._register((0,S.AV)(this._content,{width:this._width,height:this._height})),this._register((0,l.yC)(((e,t)=>{this._model.currentGroup.read(e),this._render(t)}))),this._register((0,s.b2)(this.domNode,"keydown",(e=>{(e.equals(18)||e.equals(2066)||e.equals(530))&&(e.preventDefault(),this._model.goToNextLine()),(e.equals(16)||e.equals(2064)||e.equals(528))&&(e.preventDefault(),this._model.goToPreviousLine()),(e.equals(9)||e.equals(2057)||e.equals(521)||e.equals(1033))&&(e.preventDefault(),this._model.close()),(e.equals(10)||e.equals(3))&&(e.preventDefault(),this._model.revealCurrentElementInEditor())})))}_render(e){const t=this._models.getOriginalOptions(),i=this._models.getModifiedOptions(),n=document.createElement("div");n.className="diff-review-table",n.setAttribute("role","list"),n.setAttribute("aria-label",(0,O.kg)("ariaLabel","Accessible Diff Viewer. Use arrow up and down to navigate.")),(0,E.M)(n,i.get(50)),(0,s.Ln)(this._content,n);const r=this._models.getOriginalModel(),o=this._models.getModifiedModel();if(!r||!o)return;const a=r.getOptions(),c=o.getOptions(),h=i.get(67),d=this._model.currentGroup.get();for(const u of d?.lines||[]){if(!d)break;let g;if(u.type===j.Header){const e=document.createElement("div");e.className="diff-review-row",e.setAttribute("role","listitem");const t=d.range,i=this._model.currentGroupIndex.get(),s=this._model.groups.get().length,n=e=>0===e?(0,O.kg)("no_lines_changed","no lines changed"):1===e?(0,O.kg)("one_line_changed","1 line changed"):(0,O.kg)("more_lines_changed","{0} lines changed",e),r=n(t.original.length),o=n(t.modified.length);e.setAttribute("aria-label",(0,O.kg)({key:"header",comment:["This is the ARIA label for a git diff header.","A git diff header looks like this: @@ -154,12 +159,39 @@.","That encodes that at original line 154 (which is now line 159), 12 lines were removed/changed with 39 lines.","Variables 0 and 1 refer to the diff index out of total number of diffs.","Variables 2 and 4 will be numbers (a line number).",'Variables 3 and 5 will be "no lines changed", "1 line changed" or "X lines changed", localized separately.']},"Difference {0} of {1}: original line {2}, {3}, modified line {4}, {5}",i+1,s,t.original.startLineNumber,r,t.modified.startLineNumber,o));const a=document.createElement("div");a.className="diff-review-cell diff-review-summary",a.appendChild(document.createTextNode(`${i+1}/${s}: @@ -${t.original.startLineNumber},${t.original.length} +${t.modified.startLineNumber},${t.modified.length} @@`)),e.appendChild(a),g=e}else g=this._createRow(u,h,this._width.get(),t,r,a,i,o,c);n.appendChild(g);const p=(0,l.un)((e=>this._model.currentElement.read(e)===u));e.add((0,l.fm)((e=>{const t=p.read(e);g.tabIndex=t?0:-1,t&&g.focus()}))),e.add((0,s.ko)(g,"focus",(()=>{this._model.goToLine(u)})))}this._scrollbar.scanDomNode()}_createRow(e,t,i,s,n,r,o,a,l){const c=s.get(146),h=c.glyphMarginWidth+c.lineNumbersWidth,d=o.get(146),u=10+d.glyphMarginWidth+d.lineNumbersWidth;let g="diff-review-row",p="";let m=null;switch(e.type){case j.Added:g="diff-review-row line-insert",p=" char-insert",m=H;break;case j.Deleted:g="diff-review-row line-delete",p=" char-delete",m=B}const f=document.createElement("div");f.style.minWidth=i+"px",f.className=g,f.setAttribute("role","listitem"),f.ariaLevel="";const _=document.createElement("div");_.className="diff-review-cell",_.style.height=`${t}px`,f.appendChild(_);const v=document.createElement("span");v.style.width=h+"px",v.style.minWidth=h+"px",v.className="diff-review-line-number"+p,void 0!==e.originalLineNumber?v.appendChild(document.createTextNode(String(e.originalLineNumber))):v.innerText="\xa0",_.appendChild(v);const C=document.createElement("span");C.style.width=u+"px",C.style.minWidth=u+"px",C.style.paddingRight="10px",C.className="diff-review-line-number"+p,void 0!==e.modifiedLineNumber?C.appendChild(document.createTextNode(String(e.modifiedLineNumber))):C.innerText="\xa0",_.appendChild(C);const E=document.createElement("span");if(E.className="diff-review-spacer",m){const e=document.createElement("span");e.className=b.L.asClassName(m),e.innerText="\xa0\xa0",E.appendChild(e)}else E.innerText="\xa0\xa0";let S;if(_.appendChild(E),void 0!==e.modifiedLineNumber){let t=this._getLineHtml(a,o,l.tabSize,e.modifiedLineNumber,this._languageService.languageIdCodec);V._ttPolicy&&(t=V._ttPolicy.createHTML(t)),_.insertAdjacentHTML("beforeend",t),S=a.getLineContent(e.modifiedLineNumber)}else{let t=this._getLineHtml(n,s,r.tabSize,e.originalLineNumber,this._languageService.languageIdCodec);V._ttPolicy&&(t=V._ttPolicy.createHTML(t)),_.insertAdjacentHTML("beforeend",t),S=n.getLineContent(e.originalLineNumber)}0===S.length&&(S=(0,O.kg)("blankLine","blank"));let y="";switch(e.type){case j.Unchanged:y=e.originalLineNumber===e.modifiedLineNumber?(0,O.kg)({key:"unchangedLine",comment:["The placeholders are contents of the line and should not be translated."]},"{0} unchanged line {1}",S,e.originalLineNumber):(0,O.kg)("equalLine","{0} original line {1} modified line {2}",S,e.originalLineNumber,e.modifiedLineNumber);break;case j.Added:y=(0,O.kg)("insertLine","+ {0} modified line {1}",S,e.modifiedLineNumber);break;case j.Deleted:y=(0,O.kg)("deleteLine","- {0} original line {1}",S,e.originalLineNumber)}return f.setAttribute("aria-label",y),f}_getLineHtml(e,t,i,s,n){const r=e.getLineContent(s),o=t.get(50),a=A.f.createEmpty(r,n),l=I.qL.isBasicASCII(r,e.mightContainNonBasicASCII()),c=I.qL.containsRTL(r,l,e.mightContainRTL());return(0,N.Md)(new N.zL(o.isMonospace&&!t.get(33),o.canUseHalfwidthRightwardsArrow,r,!1,l,c,0,a,[],i,0,o.spaceWidth,o.middotWidth,o.wsmiddotWidth,t.get(118),t.get(100),t.get(95),t.get(51)!==y.Bc.OFF,null)).html}};X=F([U(5,k.L)],X);class Z{constructor(e){this.editors=e}getOriginalModel(){return this.editors.original.getModel()}getOriginalOptions(){return this.editors.original.getOptions()}originalReveal(e){this.editors.original.revealRange(e),this.editors.original.setSelection(e),this.editors.original.focus()}getModifiedModel(){return this.editors.modified.getModel()}getModifiedOptions(){return this.editors.modified.getOptions()}modifiedReveal(e){e&&(this.editors.modified.revealRange(e),this.editors.modified.setSelection(e)),this.editors.modified.focus()}modifiedSetSelection(e){this.editors.modified.setSelection(e)}modifiedFocus(){this.editors.modified.focus()}getModifiedPosition(){return this.editors.modified.getPosition()??void 0}}var J=i(90766),ee=i(631),te=i(10691),ie=i(18447),se=i(94746),ne=i(41127),re=i(26746),oe=i(94650),ae=i(84084),le=i(82518),ce=i(66782),he=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},de=function(e,t){return function(i,s){t(i,s,e)}};let ue=class extends a.jG{setActiveMovedText(e){this._activeMovedText.set(e,void 0)}constructor(e,t,i){super(),this.model=e,this._options=t,this._diffProviderFactoryService=i,this._isDiffUpToDate=(0,l.FY)(this,!1),this.isDiffUpToDate=this._isDiffUpToDate,this._diff=(0,l.FY)(this,void 0),this.diff=this._diff,this._unchangedRegions=(0,l.FY)(this,void 0),this.unchangedRegions=(0,l.un)(this,(e=>this._options.hideUnchangedRegions.read(e)?this._unchangedRegions.read(e)?.regions??[]:((0,l.Rn)((e=>{for(const t of this._unchangedRegions.get()?.regions||[])t.collapseAll(e)})),[]))),this.movedTextToCompare=(0,l.FY)(this,void 0),this._activeMovedText=(0,l.FY)(this,void 0),this._hoveredMovedText=(0,l.FY)(this,void 0),this.activeMovedText=(0,l.un)(this,(e=>this.movedTextToCompare.read(e)??this._hoveredMovedText.read(e)??this._activeMovedText.read(e))),this._cancellationTokenSource=new ie.Qi,this._diffProvider=(0,l.un)(this,(e=>{const t=this._diffProviderFactoryService.createDiffProvider({diffAlgorithm:this._options.diffAlgorithm.read(e)});return{diffProvider:t,onChangeSignal:(0,l.yQ)("onDidChange",t.onDidChange)}})),this._register((0,a.s)((()=>this._cancellationTokenSource.cancel())));const s=(0,l.Yd)("contentChangedSignal"),n=this._register(new J.uC((()=>s.trigger(void 0)),200));this._register((0,l.fm)((t=>{const i=this._unchangedRegions.read(t);if(!i||i.regions.some((e=>e.isDragged.read(t))))return;const s=i.originalDecorationIds.map((t=>e.original.getDecorationRange(t))).map((e=>e?w.M.fromRangeInclusive(e):void 0)),n=i.modifiedDecorationIds.map((t=>e.modified.getDecorationRange(t))).map((e=>e?w.M.fromRangeInclusive(e):void 0)),r=i.regions.map(((e,i)=>s[i]&&n[i]?new me(s[i].startLineNumber,n[i].startLineNumber,s[i].length,e.visibleLineCountTop.read(t),e.visibleLineCountBottom.read(t)):void 0)).filter(ee.O9),o=[];let a=!1;for(const e of(0,v.n)(r,((e,i)=>e.getHiddenModifiedRange(t).endLineNumberExclusive===i.getHiddenModifiedRange(t).startLineNumber)))if(e.length>1){a=!0;const t=e.reduce(((e,t)=>e+t.lineCount),0),i=new me(e[0].originalLineNumber,e[0].modifiedLineNumber,t,e[0].visibleLineCountTop.get(),e[e.length-1].visibleLineCountBottom.get());o.push(i)}else o.push(e[0]);if(a){const t=e.original.deltaDecorations(i.originalDecorationIds,o.map((e=>({range:e.originalUnchangedRange.toInclusiveRange(),options:{description:"unchanged"}})))),s=e.modified.deltaDecorations(i.modifiedDecorationIds,o.map((e=>({range:e.modifiedUnchangedRange.toInclusiveRange(),options:{description:"unchanged"}}))));(0,l.Rn)((e=>{this._unchangedRegions.set({regions:o,originalDecorationIds:t,modifiedDecorationIds:s},e)}))}})));const r=(t,i,s)=>{const n=me.fromDiffs(t.changes,e.original.getLineCount(),e.modified.getLineCount(),this._options.hideUnchangedRegionsMinimumLineCount.read(s),this._options.hideUnchangedRegionsContextLineCount.read(s));let r;const o=this._unchangedRegions.get();if(o){const t=o.originalDecorationIds.map((t=>e.original.getDecorationRange(t))).map((e=>e?w.M.fromRangeInclusive(e):void 0)),i=o.modifiedDecorationIds.map((t=>e.modified.getDecorationRange(t))).map((e=>e?w.M.fromRangeInclusive(e):void 0));let n=(0,S.EK)(o.regions.map(((e,s)=>{if(!t[s]||!i[s])return;const n=t[s].length;return new me(t[s].startLineNumber,i[s].startLineNumber,n,Math.min(e.visibleLineCountTop.get(),n),Math.min(e.visibleLineCountBottom.get(),n-e.visibleLineCountTop.get()))})).filter(ee.O9),((e,t)=>!t||e.modifiedLineNumber>=t.modifiedLineNumber+t.lineCount&&e.originalLineNumber>=t.originalLineNumber+t.lineCount)).map((e=>new x.WL(e.getHiddenOriginalRange(s),e.getHiddenModifiedRange(s))));n=x.WL.clip(n,w.M.ofLength(1,e.original.getLineCount()),w.M.ofLength(1,e.modified.getLineCount())),r=x.WL.inverse(n,e.original.getLineCount(),e.modified.getLineCount())}const a=[];if(r)for(const e of n){const t=r.filter((t=>t.original.intersectsStrict(e.originalUnchangedRange)&&t.modified.intersectsStrict(e.modifiedUnchangedRange)));a.push(...e.setVisibleRanges(t,i))}else a.push(...n);const l=e.original.deltaDecorations(o?.originalDecorationIds||[],a.map((e=>({range:e.originalUnchangedRange.toInclusiveRange(),options:{description:"unchanged"}})))),c=e.modified.deltaDecorations(o?.modifiedDecorationIds||[],a.map((e=>({range:e.modifiedUnchangedRange.toInclusiveRange(),options:{description:"unchanged"}}))));this._unchangedRegions.set({regions:a,originalDecorationIds:l,modifiedDecorationIds:c},i)};this._register(e.modified.onDidChangeContent((t=>{if(this._diff.get()){const i=oe.c.fromModelContentChanges(t.changes),s=_e(this._lastDiff,i,e.original,e.modified);s&&(this._lastDiff=s,(0,l.Rn)((e=>{this._diff.set(ge.fromDiffResult(this._lastDiff),e),r(s,e);const t=this.movedTextToCompare.get();this.movedTextToCompare.set(t?this._lastDiff.moves.find((e=>e.lineRangeMapping.modified.intersect(t.lineRangeMapping.modified))):void 0,e)})))}this._isDiffUpToDate.set(!1,void 0),n.schedule()}))),this._register(e.original.onDidChangeContent((t=>{if(this._diff.get()){const i=oe.c.fromModelContentChanges(t.changes),s=fe(this._lastDiff,i,e.original,e.modified);s&&(this._lastDiff=s,(0,l.Rn)((e=>{this._diff.set(ge.fromDiffResult(this._lastDiff),e),r(s,e);const t=this.movedTextToCompare.get();this.movedTextToCompare.set(t?this._lastDiff.moves.find((e=>e.lineRangeMapping.modified.intersect(t.lineRangeMapping.modified))):void 0,e)})))}this._isDiffUpToDate.set(!1,void 0),n.schedule()}))),this._register((0,l.yC)((async(t,i)=>{this._options.hideUnchangedRegionsMinimumLineCount.read(t),this._options.hideUnchangedRegionsContextLineCount.read(t),n.cancel(),s.read(t);const o=this._diffProvider.read(t);o.onChangeSignal.read(t),(0,ne.b)(re.D8,t),(0,ne.b)(le.NC,t),this._isDiffUpToDate.set(!1,void 0);let a=[];i.add(e.original.onDidChangeContent((e=>{const t=oe.c.fromModelContentChanges(e.changes);a=(0,ae.M)(a,t)})));let c=[];i.add(e.modified.onDidChangeContent((e=>{const t=oe.c.fromModelContentChanges(e.changes);c=(0,ae.M)(c,t)})));let h=await o.diffProvider.computeDiff(e.original,e.modified,{ignoreTrimWhitespace:this._options.ignoreTrimWhitespace.read(t),maxComputationTimeMs:this._options.maxComputationTimeMs.read(t),computeMoves:this._options.showMoves.read(t)},this._cancellationTokenSource.token);var d,u,g;this._cancellationTokenSource.token.isCancellationRequested||(e.original.isDisposed()||e.modified.isDisposed()||(d=h,u=e.original,g=e.modified,h={changes:d.changes.map((e=>new x.wm(e.original,e.modified,e.innerChanges?e.innerChanges.map((e=>function(e,t,i){let s=e.originalRange,n=e.modifiedRange;return 1===s.startColumn&&1===n.startColumn&&(1!==s.endColumn||1!==n.endColumn)&&s.endColumn===t.getLineMaxColumn(s.endLineNumber)&&n.endColumn===i.getLineMaxColumn(n.endLineNumber)&&s.endLineNumber{r(h,e),this._lastDiff=h;const t=ge.fromDiffResult(h);this._diff.set(t,e),this._isDiffUpToDate.set(!0,e);const i=this.movedTextToCompare.get();this.movedTextToCompare.set(i?this._lastDiff.moves.find((e=>e.lineRangeMapping.modified.intersect(i.lineRangeMapping.modified))):void 0,e)}))))})))}ensureModifiedLineIsVisible(e,t,i){if(0===this.diff.get()?.mappings.length)return;const s=this._unchangedRegions.get()?.regions||[];for(const n of s)if(n.getHiddenModifiedRange(void 0).contains(e))return void n.showModifiedLine(e,t,i)}ensureOriginalLineIsVisible(e,t,i){if(0===this.diff.get()?.mappings.length)return;const s=this._unchangedRegions.get()?.regions||[];for(const n of s)if(n.getHiddenOriginalRange(void 0).contains(e))return void n.showOriginalLine(e,t,i)}async waitForDiff(){await(0,l.oJ)(this.isDiffUpToDate,(e=>e))}serializeState(){const e=this._unchangedRegions.get();return{collapsedRegions:e?.regions.map((e=>({range:e.getHiddenModifiedRange(void 0).serialize()})))}}restoreSerializedState(e){const t=e.collapsedRegions?.map((e=>w.M.deserialize(e.range))),i=this._unchangedRegions.get();i&&t&&(0,l.Rn)((e=>{for(const s of i.regions)for(const i of t)if(s.modifiedUnchangedRange.intersect(i)){s.setHiddenModifiedRange(i,e);break}}))}};ue=he([de(2,se.Hg)],ue);class ge{static fromDiffResult(e){return new ge(e.changes.map((e=>new pe(e))),e.moves||[],e.identical,e.quitEarly)}constructor(e,t,i,s){this.mappings=e,this.movedTexts=t,this.identical=i,this.quitEarly=s}}class pe{constructor(e){this.lineRangeMapping=e}}class me{static fromDiffs(e,t,i,s,n){const r=x.wm.inverse(e,t,i),o=[];for(const a of r){let e=a.original.startLineNumber,r=a.modified.startLineNumber,l=a.original.length;const c=1===e&&1===r,h=e+l===t+1&&r+l===i+1;(c||h)&&l>=n+s?(c&&!h&&(l-=n),h&&!c&&(e+=n,r+=n,l-=n),o.push(new me(e,r,l,0,0))):l>=2*n+s&&(e+=n,r+=n,l-=2*n,o.push(new me(e,r,l,0,0)))}return o}get originalUnchangedRange(){return w.M.ofLength(this.originalLineNumber,this.lineCount)}get modifiedUnchangedRange(){return w.M.ofLength(this.modifiedLineNumber,this.lineCount)}constructor(e,t,i,s,n){this.originalLineNumber=e,this.modifiedLineNumber=t,this.lineCount=i,this._visibleLineCountTop=(0,l.FY)(this,0),this.visibleLineCountTop=this._visibleLineCountTop,this._visibleLineCountBottom=(0,l.FY)(this,0),this.visibleLineCountBottom=this._visibleLineCountBottom,this._shouldHideControls=(0,l.un)(this,(e=>this.visibleLineCountTop.read(e)+this.visibleLineCountBottom.read(e)===this.lineCount&&!this.isDragged.read(e))),this.isDragged=(0,l.FY)(this,void 0);const r=Math.max(Math.min(s,this.lineCount),0),o=Math.max(Math.min(n,this.lineCount-s),0);(0,ce.V7)(s===r),(0,ce.V7)(n===o),this._visibleLineCountTop.set(r,void 0),this._visibleLineCountBottom.set(o,void 0)}setVisibleRanges(e,t){const i=[],s=new w.S(e.map((e=>e.modified))).subtractFrom(this.modifiedUnchangedRange);let n=this.originalLineNumber,r=this.modifiedLineNumber;const o=this.modifiedLineNumber+this.lineCount;if(0===s.ranges.length)this.showAll(t),i.push(this);else{let e=0;for(const a of s.ranges){const l=e===s.ranges.length-1;e++;const c=(l?o:a.endLineNumberExclusive)-r,h=new me(n,r,c,0,0);h.setHiddenModifiedRange(a,t),i.push(h),n=h.originalUnchangedRange.endLineNumberExclusive,r=h.modifiedUnchangedRange.endLineNumberExclusive}}return i}shouldHideControls(e){return this._shouldHideControls.read(e)}getHiddenOriginalRange(e){return w.M.ofLength(this.originalLineNumber+this._visibleLineCountTop.read(e),this.lineCount-this._visibleLineCountTop.read(e)-this._visibleLineCountBottom.read(e))}getHiddenModifiedRange(e){return w.M.ofLength(this.modifiedLineNumber+this._visibleLineCountTop.read(e),this.lineCount-this._visibleLineCountTop.read(e)-this._visibleLineCountBottom.read(e))}setHiddenModifiedRange(e,t){const i=e.startLineNumber-this.modifiedLineNumber,s=this.modifiedLineNumber+this.lineCount-e.endLineNumberExclusive;this.setState(i,s,t)}getMaxVisibleLineCountTop(){return this.lineCount-this._visibleLineCountBottom.get()}getMaxVisibleLineCountBottom(){return this.lineCount-this._visibleLineCountTop.get()}showMoreAbove(e=10,t){const i=this.getMaxVisibleLineCountTop();this._visibleLineCountTop.set(Math.min(this._visibleLineCountTop.get()+e,i),t)}showMoreBelow(e=10,t){const i=this.lineCount-this._visibleLineCountTop.get();this._visibleLineCountBottom.set(Math.min(this._visibleLineCountBottom.get()+e,i),t)}showAll(e){this._visibleLineCountBottom.set(this.lineCount-this._visibleLineCountTop.get(),e)}showModifiedLine(e,t,i){const s=e+1-(this.modifiedLineNumber+this._visibleLineCountTop.get()),n=this.modifiedLineNumber-this._visibleLineCountBottom.get()+this.lineCount-e;0===t&&s{this._contextMenuService.showContextMenu({domForShadowRoot:u?i.getDomNode()??void 0:void 0,getAnchor:()=>({x:e,y:t}),getActions:()=>{const e=[],t=n.modified.isEmpty;e.push(new _.rc("diff.clipboard.copyDeletedContent",t?n.original.length>1?(0,O.kg)("diff.clipboard.copyDeletedLinesContent.label","Copy deleted lines"):(0,O.kg)("diff.clipboard.copyDeletedLinesContent.single.label","Copy deleted line"):n.original.length>1?(0,O.kg)("diff.clipboard.copyChangedLinesContent.label","Copy changed lines"):(0,O.kg)("diff.clipboard.copyChangedLinesContent.single.label","Copy changed line"),void 0,!0,(async()=>{const e=this._originalTextModel.getValueInRange(n.original.toExclusiveRange());await this._clipboardService.writeText(e)}))),n.original.length>1&&e.push(new _.rc("diff.clipboard.copyDeletedLineContent",t?(0,O.kg)("diff.clipboard.copyDeletedLineContent.label","Copy deleted line ({0})",n.original.startLineNumber+d):(0,O.kg)("diff.clipboard.copyChangedLineContent.label","Copy changed line ({0})",n.original.startLineNumber+d),void 0,!0,(async()=>{let e=this._originalTextModel.getLineContent(n.original.startLineNumber+d);if(""===e){e=0===this._originalTextModel.getEndOfLineSequence()?"\n":"\r\n"}await this._clipboardService.writeText(e)})));return i.getOption(92)||e.push(new _.rc("diff.inline.revertChange",(0,O.kg)("diff.inline.revertChange.label","Revert this change"),void 0,!0,(async()=>{this._editor.revert(this._diff)}))),e},autoSelectFirstItem:!0})};this._register((0,s.b2)(this._diffActions,"mousedown",(e=>{if(!e.leftButton)return;const{top:t,height:i}=(0,s.BK)(this._diffActions),n=Math.floor(h/3);e.preventDefault(),g(e.posx,t+i+n)}))),this._register(i.onMouseMove((e=>{8!==e.target.type&&5!==e.target.type||e.target.detail.viewZoneId!==this._getViewZoneId()?this.visibility=!1:(d=this._updateLightBulbPosition(this._marginDomNode,e.event.browserEvent.y,h),this.visibility=!0)}))),this._register(i.onMouseDown((e=>{if(e.event.leftButton&&(8===e.target.type||5===e.target.type)){e.target.detail.viewZoneId===this._getViewZoneId()&&(e.event.preventDefault(),d=this._updateLightBulbPosition(this._marginDomNode,e.event.browserEvent.y,h),g(e.event.posx,e.event.posy+h))}})))}_updateLightBulbPosition(e,t,i){const{top:n}=(0,s.BK)(e),r=t-n,o=Math.floor(r/i),a=o*i;if(this._diffActions.style.top=`${a}px`,this._viewLineCounts){let e=0;for(let t=0;te});function ye(e,t,i,s){(0,E.M)(s,t.fontInfo);const n=i.length>0,r=new be.fe(1e4);let o=0,a=0;const l=[];for(let d=0;d');const l=t.getLineContent(),c=I.qL.isBasicASCII(l,n),h=I.qL.containsRTL(l,c,r),d=(0,N.UW)(new N.zL(o.fontInfo.isMonospace&&!o.disableMonospaceOptimizations,o.fontInfo.canUseHalfwidthRightwardsArrow,l,!1,c,h,0,t,i,o.tabSize,0,o.fontInfo.spaceWidth,o.fontInfo.middotWidth,o.fontInfo.wsmiddotWidth,o.stopRenderingLineAfter,o.renderWhitespace,o.renderControlCharacters,o.fontLigatures!==y.Bc.OFF,null),a);return a.appendString(""),d.characterMapping.getHorizontalOffset(d.characterMapping.length)}var Te=i(54770),xe=i(47508),ke=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ae=function(e,t){return function(i,s){t(i,s,e)}};let Ne=class extends a.jG{constructor(e,t,i,n,r,o,c,h,d,u){super(),this._targetWindow=e,this._editors=t,this._diffModel=i,this._options=n,this._diffEditorWidget=r,this._canIgnoreViewZoneUpdateEvent=o,this._origViewZonesToIgnore=c,this._modViewZonesToIgnore=h,this._clipboardService=d,this._contextMenuService=u,this._originalTopPadding=(0,l.FY)(this,0),this._originalScrollOffset=(0,l.FY)(this,0),this._originalScrollOffsetAnimated=(0,S.Nu)(this._targetWindow,this._originalScrollOffset,this._store),this._modifiedTopPadding=(0,l.FY)(this,0),this._modifiedScrollOffset=(0,l.FY)(this,0),this._modifiedScrollOffsetAnimated=(0,S.Nu)(this._targetWindow,this._modifiedScrollOffset,this._store);const g=(0,l.FY)("invalidateAlignmentsState",0),p=this._register(new J.uC((()=>{g.set(g.get()+1,void 0)}),0));this._register(this._editors.original.onDidChangeViewZones((e=>{this._canIgnoreViewZoneUpdateEvent()||p.schedule()}))),this._register(this._editors.modified.onDidChangeViewZones((e=>{this._canIgnoreViewZoneUpdateEvent()||p.schedule()}))),this._register(this._editors.original.onDidChangeConfiguration((e=>{(e.hasChanged(147)||e.hasChanged(67))&&p.schedule()}))),this._register(this._editors.modified.onDidChangeConfiguration((e=>{(e.hasChanged(147)||e.hasChanged(67))&&p.schedule()})));const m=this._diffModel.map((e=>e?(0,l.y0)(this,e.model.original.onDidChangeTokens,(()=>2===e.model.original.tokenization.backgroundTokenizationState)):void 0)).map(((e,t)=>e?.read(t))),f=(0,l.un)((e=>{const t=this._diffModel.read(e),i=t?.diff.read(e);if(!t||!i)return null;g.read(e);const s=this._options.renderSideBySide.read(e);return Ie(this._editors.original,this._editors.modified,i.mappings,this._origViewZonesToIgnore,this._modViewZonesToIgnore,s)})),_=(0,l.un)((e=>{const t=this._diffModel.read(e)?.movedTextToCompare.read(e);if(!t)return null;g.read(e);const i=t.changes.map((e=>new pe(e)));return Ie(this._editors.original,this._editors.modified,i,this._origViewZonesToIgnore,this._modViewZonesToIgnore,!0)}));function v(){const e=document.createElement("div");return e.className="diagonal-fill",e}const y=this._register(new a.Cm);this.viewZones=(0,l.rm)(this,((e,t)=>{y.clear();const i=f.read(e)||[],n=[],o=[],a=this._modifiedTopPadding.read(e);a>0&&o.push({afterLineNumber:0,domNode:document.createElement("div"),heightInPx:a,showInHiddenAreas:!0,suppressMouseDown:!0});const l=this._originalTopPadding.read(e);l>0&&n.push({afterLineNumber:0,domNode:document.createElement("div"),heightInPx:l,showInHiddenAreas:!0,suppressMouseDown:!0});const c=this._options.renderSideBySide.read(e),h=c?void 0:this._editors.modified._getViewModel()?.createLineBreaksComputer();if(h){const R=this._editors.original.getModel();for(const T of i)if(T.diff)for(let x=T.originalRange.startLineNumber;xR.getLineCount())return{orig:n,mod:o};h?.addRequest(R.getLineContent(x),null,null)}}const d=h?.finalize()??[];let u=0;const g=this._editors.modified.getOption(67),p=this._diffModel.read(e)?.movedTextToCompare.read(e),S=this._editors.original.getModel()?.mightContainNonBasicASCII()??!1,w=this._editors.original.getModel()?.mightContainRTL()??!1,L=Le.fromEditor(this._editors.modified);for(const k of i)if(!k.diff||c||this._options.useTrueInlineDiffRendering.read(e)&&De(k.diff)){const A=k.modifiedHeightInPx-k.originalHeightInPx;if(A>0){if(p?.lineRangeMapping.original.delta(-1).deltaLength(2).contains(k.originalRange.endLineNumberExclusive-1))continue;n.push({afterLineNumber:k.originalRange.endLineNumberExclusive-1,domNode:v(),heightInPx:A,showInHiddenAreas:!0,suppressMouseDown:!0})}else{if(p?.lineRangeMapping.modified.delta(-1).deltaLength(2).contains(k.modifiedRange.endLineNumberExclusive-1))continue;function N(){const e=document.createElement("div");return e.className="arrow-revert-change "+b.L.asClassName(C.W.arrowRight),t.add((0,s.ko)(e,"mousedown",(e=>e.stopPropagation()))),t.add((0,s.ko)(e,"click",(e=>{e.stopPropagation(),r.revert(k.diff)}))),(0,s.$)("div",{},e)}let O;k.diff&&k.diff.modified.isEmpty&&this._options.shouldRenderOldRevertArrows.read(e)&&(O=N()),o.push({afterLineNumber:k.modifiedRange.endLineNumberExclusive-1,domNode:v(),heightInPx:-A,marginDomNode:O,showInHiddenAreas:!0,suppressMouseDown:!0})}}else{if(!k.originalRange.isEmpty){m.read(e);const M=document.createElement("div");M.classList.add("view-lines","line-delete","monaco-mouse-cursor-text");const P=this._editors.original.getModel();if(k.originalRange.endLineNumberExclusive-1>P.getLineCount())return{orig:n,mod:o};const F=new we(k.originalRange.mapToLineArray((e=>P.tokenization.getLineTokens(e))),k.originalRange.mapToLineArray((e=>d[u++])),S,w),U=[];for(const V of k.diff.innerChanges||[])U.push(new I.kI(V.originalRange.delta(-(k.diff.original.startLineNumber-1)),te.Zb.className,0));const H=ye(F,L,U,M),B=document.createElement("div");if(B.className="inline-deleted-margin-view-zone",(0,E.M)(B,L.fontInfo),this._options.renderIndicators.read(e))for(let z=0;z(0,ee.eU)(W)),B,this._editors.modified,k.diff,this._diffEditorWidget,H.viewLineCounts,this._editors.original.getModel(),this._contextMenuService,this._clipboardService));for(let j=0;j1&&n.push({afterLineNumber:k.originalRange.startLineNumber+j,domNode:v(),heightInPx:(K-1)*g,showInHiddenAreas:!0,suppressMouseDown:!0})}o.push({afterLineNumber:k.modifiedRange.startLineNumber-1,domNode:M,heightInPx:H.heightInLines*g,minWidthInPx:H.minWidthInPx,marginDomNode:B,setZoneId(e){W=e},showInHiddenAreas:!0,suppressMouseDown:!0})}const D=document.createElement("div");D.className="gutter-delete",n.push({afterLineNumber:k.originalRange.endLineNumberExclusive-1,domNode:v(),heightInPx:k.modifiedHeightInPx,marginDomNode:D,showInHiddenAreas:!0,suppressMouseDown:!0})}for(const Y of _.read(e)??[]){if(!p?.lineRangeMapping.original.intersect(Y.originalRange)||!p?.lineRangeMapping.modified.intersect(Y.modifiedRange))continue;const q=Y.modifiedHeightInPx-Y.originalHeightInPx;q>0?n.push({afterLineNumber:Y.originalRange.endLineNumberExclusive-1,domNode:v(),heightInPx:q,showInHiddenAreas:!0,suppressMouseDown:!0}):o.push({afterLineNumber:Y.modifiedRange.endLineNumberExclusive-1,domNode:v(),heightInPx:-q,showInHiddenAreas:!0,suppressMouseDown:!0})}return{orig:n,mod:o}}));let w=!1;this._register(this._editors.original.onDidScrollChange((e=>{e.scrollLeftChanged&&!w&&(w=!0,this._editors.modified.setScrollLeft(e.scrollLeft),w=!1)}))),this._register(this._editors.modified.onDidScrollChange((e=>{e.scrollLeftChanged&&!w&&(w=!0,this._editors.original.setScrollLeft(e.scrollLeft),w=!1)}))),this._originalScrollTop=(0,l.y0)(this._editors.original.onDidScrollChange,(()=>this._editors.original.getScrollTop())),this._modifiedScrollTop=(0,l.y0)(this._editors.modified.onDidScrollChange,(()=>this._editors.modified.getScrollTop())),this._register((0,l.fm)((e=>{const t=this._originalScrollTop.read(e)-(this._originalScrollOffsetAnimated.get()-this._modifiedScrollOffsetAnimated.read(e))-(this._originalTopPadding.get()-this._modifiedTopPadding.read(e));t!==this._editors.modified.getScrollTop()&&this._editors.modified.setScrollTop(t,1)}))),this._register((0,l.fm)((e=>{const t=this._modifiedScrollTop.read(e)-(this._modifiedScrollOffsetAnimated.get()-this._originalScrollOffsetAnimated.read(e))-(this._modifiedTopPadding.get()-this._originalTopPadding.read(e));t!==this._editors.original.getScrollTop()&&this._editors.original.setScrollTop(t,1)}))),this._register((0,l.fm)((e=>{const t=this._diffModel.read(e)?.movedTextToCompare.read(e);let i=0;if(t){const e=this._editors.original.getTopForLineNumber(t.lineRangeMapping.original.startLineNumber,!0)-this._originalTopPadding.get();i=this._editors.modified.getTopForLineNumber(t.lineRangeMapping.modified.startLineNumber,!0)-this._modifiedTopPadding.get()-e}i>0?(this._modifiedTopPadding.set(0,void 0),this._originalTopPadding.set(i,void 0)):i<0?(this._modifiedTopPadding.set(-i,void 0),this._originalTopPadding.set(0,void 0)):setTimeout((()=>{this._modifiedTopPadding.set(0,void 0),this._originalTopPadding.set(0,void 0)}),400),this._editors.modified.hasTextFocus()?this._originalScrollOffset.set(this._modifiedScrollOffset.get()-i,void 0,!0):this._modifiedScrollOffset.set(this._originalScrollOffset.get()+i,void 0,!0)})))}};function Ie(e,t,i,s,n,r){const o=new v.j3(Oe(e,s)),a=new v.j3(Oe(t,n)),l=e.getOption(67),c=t.getOption(67),h=[];let d=0,u=0;function g(e,t){for(;;){let i=o.peek(),s=a.peek();if(i&&i.lineNumber>=e&&(i=void 0),s&&s.lineNumber>=t&&(s=void 0),!i&&!s)break;const n=i?i.lineNumber-d:Number.MAX_VALUE,r=s?s.lineNumber-u:Number.MAX_VALUE;nr?(a.dequeue(),i={lineNumber:s.lineNumber-u+d,heightInPx:0}):(o.dequeue(),a.dequeue()),h.push({originalRange:w.M.ofLength(i.lineNumber,1),modifiedRange:w.M.ofLength(s.lineNumber,1),originalHeightInPx:l+i.heightInPx,modifiedHeightInPx:c+s.heightInPx,diff:void 0})}}for(const p of i){const m=p.lineRangeMapping;g(m.original.startLineNumber,m.modified.startLineNumber);let f=!0,_=m.modified.startLineNumber,C=m.original.startLineNumber;function b(e,t,i=!1){if(et.lineNumbere+t.heightInPx),0)??0,d=a.takeWhile((e=>e.lineNumbere+t.heightInPx),0)??0;h.push({originalRange:s,modifiedRange:n,originalHeightInPx:s.length*l+r,modifiedHeightInPx:n.length*c+d,diff:p.lineRangeMapping}),C=e,_=t}if(r)for(const E of m.innerChanges||[]){E.originalRange.startColumn>1&&E.modifiedRange.startColumn>1&&b(E.originalRange.startLineNumber,E.modifiedRange.startLineNumber);const S=e.getModel(),y=E.originalRange.endLineNumber<=S.getLineCount()?S.getLineMaxColumn(E.originalRange.endLineNumber):Number.MAX_SAFE_INTEGER;E.originalRange.endColumn1&&s.push({lineNumber:a,heightInPx:o*(e-1)})}for(const a of e.getWhitespaces()){if(t.has(a.id))continue;const e=0===a.afterLineNumber?0:r.convertViewPositionToModelPosition(new R.y(a.afterLineNumber,1)).lineNumber;i.push({lineNumber:e,heightInPx:a.height})}return(0,S.Am)(i,s,(e=>e.lineNumber),((e,t)=>({lineNumber:e.lineNumber,heightInPx:e.heightInPx+t.heightInPx})))}function De(e){return!!e.innerChanges&&e.innerChanges.every((e=>Me(e.modifiedRange)&&Me(e.originalRange)||e.originalRange.equalsRange(new T.Q(1,1,1,1))))}function Me(e){return e.startLineNumber===e.endLineNumber}Ne=ke([Ae(8,Te.h),Ae(9,xe.Z)],Ne);class Pe extends a.jG{static{this.movedCodeBlockPadding=4}constructor(e,t,i,s,n){super(),this._rootElement=e,this._diffModel=t,this._originalEditorLayoutInfo=i,this._modifiedEditorLayoutInfo=s,this._editors=n,this._originalScrollTop=(0,l.y0)(this,this._editors.original.onDidScrollChange,(()=>this._editors.original.getScrollTop())),this._modifiedScrollTop=(0,l.y0)(this,this._editors.modified.onDidScrollChange,(()=>this._editors.modified.getScrollTop())),this._viewZonesChanged=(0,l.yQ)("onDidChangeViewZones",this._editors.modified.onDidChangeViewZones),this.width=(0,l.FY)(this,0),this._modifiedViewZonesChangedSignal=(0,l.yQ)("modified.onDidChangeViewZones",this._editors.modified.onDidChangeViewZones),this._originalViewZonesChangedSignal=(0,l.yQ)("original.onDidChangeViewZones",this._editors.original.onDidChangeViewZones),this._state=(0,l.rm)(this,((e,t)=>{this._element.replaceChildren();const i=this._diffModel.read(e),s=i?.diff.read(e)?.movedTexts;if(!s||0===s.length)return void this.width.set(0,void 0);this._viewZonesChanged.read(e);const n=this._originalEditorLayoutInfo.read(e),r=this._modifiedEditorLayoutInfo.read(e);if(!n||!r)return void this.width.set(0,void 0);this._modifiedViewZonesChangedSignal.read(e),this._originalViewZonesChangedSignal.read(e);const o=s.map((t=>{function i(e,t){return(t.getTopForLineNumber(e.startLineNumber,!0)+t.getTopForLineNumber(e.endLineNumberExclusive,!0))/2}const s=i(t.lineRangeMapping.original,this._editors.original),n=this._originalScrollTop.read(e),r=i(t.lineRangeMapping.modified,this._editors.modified),o=s-n,a=r-this._modifiedScrollTop.read(e),l=Math.min(s,r),c=Math.max(s,r);return{range:new L.L(l,c),from:o,to:a,fromWithoutScroll:s,toWithoutScroll:r,move:t}}));o.sort((0,v.nH)((0,v.VE)((e=>e.fromWithoutScroll>e.toWithoutScroll),v.TS),(0,v.VE)((e=>e.fromWithoutScroll>e.toWithoutScroll?e.fromWithoutScroll:-e.toWithoutScroll),v.U9)));const a=Fe.compute(o.map((e=>e.range))),c=n.verticalScrollbarWidth,h=10*(a.getTrackCount()-1)+20,d=c+h+(r.contentLeft-Pe.movedCodeBlockPadding);let u=0;for(const g of o){const e=c+10+10*a.getTrack(u),s=15,n=15,o=d,h=r.glyphMarginWidth+r.lineNumbersWidth,p=18,m=document.createElementNS("http://www.w3.org/2000/svg","rect");m.classList.add("arrow-rectangle"),m.setAttribute("x",""+(o-h)),m.setAttribute("y",""+(g.to-p/2)),m.setAttribute("width",`${h}`),m.setAttribute("height",`${p}`),this._element.appendChild(m);const f=document.createElementNS("http://www.w3.org/2000/svg","g"),_=document.createElementNS("http://www.w3.org/2000/svg","path");_.setAttribute("d",`M 0 ${g.from} L ${e} ${g.from} L ${e} ${g.to} L ${o-n} ${g.to}`),_.setAttribute("fill","none"),f.appendChild(_);const v=document.createElementNS("http://www.w3.org/2000/svg","polygon");v.classList.add("arrow"),t.add((0,l.fm)((e=>{_.classList.toggle("currentMove",g.move===i.activeMovedText.read(e)),v.classList.toggle("currentMove",g.move===i.activeMovedText.read(e))}))),v.setAttribute("points",`${o-n},${g.to-s/2} ${o},${g.to} ${o-n},${g.to+s/2}`),f.appendChild(v),this._element.appendChild(f),u++}this.width.set(h,void 0)})),this._element=document.createElementNS("http://www.w3.org/2000/svg","svg"),this._element.setAttribute("class","moved-blocks-lines"),this._rootElement.appendChild(this._element),this._register((0,a.s)((()=>this._element.remove()))),this._register((0,l.fm)((e=>{const t=this._originalEditorLayoutInfo.read(e),i=this._modifiedEditorLayoutInfo.read(e);t&&i&&(this._element.style.left=t.width-t.verticalScrollbarWidth+"px",this._element.style.height=`${t.height}px`,this._element.style.width=`${t.verticalScrollbarWidth+t.contentLeft-Pe.movedCodeBlockPadding+this.width.read(e)}px`)}))),this._register((0,l.OI)(this._state));const r=(0,l.un)((e=>{const t=this._diffModel.read(e),i=t?.diff.read(e);return i?i.movedTexts.map((e=>({move:e,original:new S.D1((0,l.lk)(e.lineRangeMapping.original.startLineNumber-1),18),modified:new S.D1((0,l.lk)(e.lineRangeMapping.modified.startLineNumber-1),18)}))):[]}));this._register((0,S.Vs)(this._editors.original,r.map((e=>e.map((e=>e.original)))))),this._register((0,S.Vs)(this._editors.modified,r.map((e=>e.map((e=>e.modified)))))),this._register((0,l.yC)(((e,t)=>{const i=r.read(e);for(const s of i)t.add(new Ue(this._editors.original,s.original,s.move,"original",this._diffModel.get())),t.add(new Ue(this._editors.modified,s.modified,s.move,"modified",this._diffModel.get()))})));const o=(0,l.yQ)("original.onDidFocusEditorWidget",(e=>this._editors.original.onDidFocusEditorWidget((()=>setTimeout((()=>e(void 0)),0))))),c=(0,l.yQ)("modified.onDidFocusEditorWidget",(e=>this._editors.modified.onDidFocusEditorWidget((()=>setTimeout((()=>e(void 0)),0)))));let h="modified";this._register((0,l.Y)({createEmptyChangeSummary:()=>{},handleChange:(e,t)=>(e.didChange(o)&&(h="original"),e.didChange(c)&&(h="modified"),!0)},(e=>{o.read(e),c.read(e);const t=this._diffModel.read(e);if(!t)return;const i=t.diff.read(e);let s;if(i&&"original"===h){const t=this._editors.originalCursor.read(e);t&&(s=i.movedTexts.find((e=>e.lineRangeMapping.original.contains(t.lineNumber))))}if(i&&"modified"===h){const t=this._editors.modifiedCursor.read(e);t&&(s=i.movedTexts.find((e=>e.lineRangeMapping.modified.contains(t.lineNumber))))}s!==t.movedTextToCompare.get()&&t.movedTextToCompare.set(void 0,void 0),t.setActiveMovedText(s)})))}}class Fe{static compute(e){const t=[],i=[];for(const s of e){let e=t.findIndex((e=>!e.intersectsStrict(s)));if(-1===e){const i=6;t.length>=i?e=(0,n.TM)(t,(0,v.VE)((e=>e.intersectWithRangeLength(s)),v.U9)):(e=t.length,t.push(new L.h))}t[e].addRange(s),i.push(e)}return new Fe(t.length,i)}constructor(e,t){this._trackCount=e,this.trackPerLineIdx=t}getTrack(e){return this.trackPerLineIdx[e]}getTrackCount(){return this._trackCount}}class Ue extends S.uN{constructor(e,t,i,n,r){const o=(0,s.h)("div.diff-hidden-lines-widget");super(e,t,o.root),this._editor=e,this._move=i,this._kind=n,this._diffModel=r,this._nodes=(0,s.h)("div.diff-moved-code-block",{style:{marginRight:"4px"}},[(0,s.h)("div.text-content@textContent"),(0,s.h)("div.action-bar@actionBar")]),o.root.appendChild(this._nodes.root);const a=(0,l.y0)(this._editor.onDidLayoutChange,(()=>this._editor.getLayoutInfo()));let c;this._register((0,S.AV)(this._nodes.root,{paddingRight:a.map((e=>e.verticalScrollbarWidth))})),c=i.changes.length>0?"original"===this._kind?(0,O.kg)("codeMovedToWithChanges","Code moved with changes to line {0}-{1}",this._move.lineRangeMapping.modified.startLineNumber,this._move.lineRangeMapping.modified.endLineNumberExclusive-1):(0,O.kg)("codeMovedFromWithChanges","Code moved with changes from line {0}-{1}",this._move.lineRangeMapping.original.startLineNumber,this._move.lineRangeMapping.original.endLineNumberExclusive-1):"original"===this._kind?(0,O.kg)("codeMovedTo","Code moved to line {0}-{1}",this._move.lineRangeMapping.modified.startLineNumber,this._move.lineRangeMapping.modified.endLineNumberExclusive-1):(0,O.kg)("codeMovedFrom","Code moved from line {0}-{1}",this._move.lineRangeMapping.original.startLineNumber,this._move.lineRangeMapping.original.endLineNumberExclusive-1);const h=this._register(new m.E(this._nodes.actionBar,{highlightToggledItems:!0})),d=new _.rc("",c,"",!1);h.push(d,{icon:!1,label:!0});const u=new _.rc("","Compare",b.L.asClassName(C.W.compareChanges),!0,(()=>{this._editor.focus(),this._diffModel.movedTextToCompare.set(this._diffModel.movedTextToCompare.get()===i?void 0:this._move,void 0)}));this._register((0,l.fm)((e=>{const t=this._diffModel.movedTextToCompare.read(e)===i;u.checked=t}))),h.push(u,{icon:!1,label:!0})}}class He extends a.jG{constructor(e,t,i,s){super(),this._editors=e,this._diffModel=t,this._options=i,this._decorations=(0,l.un)(this,(e=>{const t=this._diffModel.read(e),i=t?.diff.read(e);if(!i)return null;const s=this._diffModel.read(e).movedTextToCompare.read(e),n=this._options.renderIndicators.read(e),r=this._options.showEmptyDecorations.read(e),o=[],a=[];if(!s)for(const c of i.mappings)if(c.lineRangeMapping.original.isEmpty||o.push({range:c.lineRangeMapping.original.toInclusiveRange(),options:n?te.Ob:te.XT}),c.lineRangeMapping.modified.isEmpty||a.push({range:c.lineRangeMapping.modified.toInclusiveRange(),options:n?te.Kl:te.Zw}),c.lineRangeMapping.modified.isEmpty||c.lineRangeMapping.original.isEmpty)c.lineRangeMapping.original.isEmpty||o.push({range:c.lineRangeMapping.original.toInclusiveRange(),options:te.KL}),c.lineRangeMapping.modified.isEmpty||a.push({range:c.lineRangeMapping.modified.toInclusiveRange(),options:te.Ou});else{const i=this._options.useTrueInlineDiffRendering.read(e)&&De(c.lineRangeMapping);for(const e of c.lineRangeMapping.innerChanges||[])if(c.lineRangeMapping.original.contains(e.originalRange.startLineNumber)&&o.push({range:e.originalRange,options:e.originalRange.isEmpty()&&r?te.wp:te.Zb}),c.lineRangeMapping.modified.contains(e.modifiedRange.startLineNumber)&&a.push({range:e.modifiedRange,options:e.modifiedRange.isEmpty()&&r&&!i?te.GM:te.bk}),i){const i=t.model.original.getValueInRange(e.originalRange);a.push({range:e.modifiedRange,options:{description:"deleted-text",before:{content:i,inlineClassName:"inline-deleted-text"},zIndex:1e5,showIfCollapsed:!0}})}}if(s)for(const c of s.changes){const e=c.original.toInclusiveRange();e&&o.push({range:e,options:n?te.Ob:te.XT});const t=c.modified.toInclusiveRange();t&&a.push({range:t,options:n?te.Kl:te.Zw});for(const i of c.innerChanges||[])o.push({range:i.originalRange,options:te.Zb}),a.push({range:i.modifiedRange,options:te.bk})}const l=this._diffModel.read(e).activeMovedText.read(e);for(const c of i.movedTexts)o.push({range:c.lineRangeMapping.original.toInclusiveRange(),options:{description:"moved",blockClassName:"movedOriginal"+(c===l?" currentMove":""),blockPadding:[Pe.movedCodeBlockPadding,0,Pe.movedCodeBlockPadding,Pe.movedCodeBlockPadding]}}),a.push({range:c.lineRangeMapping.modified.toInclusiveRange(),options:{description:"moved",blockClassName:"movedModified"+(c===l?" currentMove":""),blockPadding:[4,0,4,4]}});return{originalDecorations:o,modifiedDecorations:a}})),this._register((0,S.pY)(this._editors.original,this._decorations.map((e=>e?.originalDecorations||[])))),this._register((0,S.pY)(this._editors.modified,this._decorations.map((e=>e?.modifiedDecorations||[]))))}}var Be=i(92403);class We{resetSash(){this._sashRatio.set(void 0,void 0)}constructor(e,t){this._options=e,this.dimensions=t,this.sashLeft=(0,c.dQ)(this,(e=>{const t=this._sashRatio.read(e)??this._options.splitViewDefaultRatio.read(e);return this._computeSashLeft(t,e)}),((e,t)=>{const i=this.dimensions.width.get();this._sashRatio.set(e/i,t)})),this._sashRatio=(0,l.FY)(this,void 0)}_computeSashLeft(e,t){const i=this.dimensions.width.read(t),s=Math.floor(this._options.splitViewDefaultRatio.read(t)*i),n=this._options.enableSplitViewResizing.read(t)?Math.floor(e*i):s,r=100;return i<=200?s:ni-r?i-r:n}}class Ve extends a.jG{constructor(e,t,i,s,n,r){super(),this._domNode=e,this._dimensions=t,this._enabled=i,this._boundarySashes=s,this.sashLeft=n,this._resetSash=r,this._sash=this._register(new Be.m(this._domNode,{getVerticalSashTop:e=>0,getVerticalSashLeft:e=>this.sashLeft.get(),getVerticalSashHeight:e=>this._dimensions.height.get()},{orientation:0})),this._startSashPosition=void 0,this._register(this._sash.onDidStart((()=>{this._startSashPosition=this.sashLeft.get()}))),this._register(this._sash.onDidChange((e=>{this.sashLeft.set(this._startSashPosition+(e.currentX-e.startX),void 0)}))),this._register(this._sash.onDidEnd((()=>this._sash.layout()))),this._register(this._sash.onDidReset((()=>this._resetSash()))),this._register((0,l.fm)((e=>{const t=this._boundarySashes.read(e);t&&(this._sash.orthogonalEndSash=t.bottom)}))),this._register((0,l.fm)((e=>{const t=this._enabled.read(e);this._sash.state=t?3:0,this.sashLeft.read(e),this._dimensions.height.read(e),this._sash.layout()})))}}class ze extends a.jG{constructor(e,t,i){super(),this._editor=e,this._domNode=t,this.itemProvider=i,this.scrollTop=(0,l.y0)(this,this._editor.onDidScrollChange,(e=>this._editor.getScrollTop())),this.isScrollTopZero=this.scrollTop.map((e=>0===e)),this.modelAttached=(0,l.y0)(this,this._editor.onDidChangeModel,(e=>this._editor.hasModel())),this.editorOnDidChangeViewZones=(0,l.yQ)("onDidChangeViewZones",this._editor.onDidChangeViewZones),this.editorOnDidContentSizeChange=(0,l.yQ)("onDidContentSizeChange",this._editor.onDidContentSizeChange),this.domNodeSizeChanged=(0,l.Yd)("domNodeSizeChanged"),this.views=new Map,this._domNode.className="gutter monaco-editor";const n=this._domNode.appendChild((0,s.h)("div.scroll-decoration",{role:"presentation",ariaHidden:"true",style:{width:"100%"}}).root),r=new ResizeObserver((()=>{(0,l.Rn)((e=>{this.domNodeSizeChanged.trigger(e)}))}));r.observe(this._domNode),this._register((0,a.s)((()=>r.disconnect()))),this._register((0,l.fm)((e=>{n.className=this.isScrollTopZero.read(e)?"":"scroll-decoration"}))),this._register((0,l.fm)((e=>this.render(e))))}dispose(){super.dispose(),(0,s.Ln)(this._domNode)}render(e){if(!this.modelAttached.read(e))return;this.domNodeSizeChanged.read(e),this.editorOnDidChangeViewZones.read(e),this.editorOnDidContentSizeChange.read(e);const t=this.scrollTop.read(e),i=this._editor.getVisibleRanges(),s=new Set(this.views.keys()),n=L.L.ofStartAndLength(0,this._domNode.clientHeight);if(!n.isEmpty)for(const r of i){const i=new w.M(r.startLineNumber,r.endLineNumber+1),o=this.itemProvider.getIntersectingGutterItems(i,e);(0,l.Rn)((e=>{for(const r of o){if(!r.range.intersect(i))continue;s.delete(r.id);let o=this.views.get(r.id);if(o)o.item.set(r,e);else{const e=document.createElement("div");this._domNode.appendChild(e);const t=(0,l.FY)("item",r),i=this.itemProvider.createView(t,e);o=new Ge(t,i,e),this.views.set(r.id,o)}const a=r.range.startLineNumber<=this._editor.getModel().getLineCount()?this._editor.getTopForLineNumber(r.range.startLineNumber,!0)-t:this._editor.getBottomForLineNumber(r.range.startLineNumber-1,!1)-t,c=(1===r.range.endLineNumberExclusive?Math.max(a,this._editor.getTopForLineNumber(r.range.startLineNumber,!1)-t):Math.max(a,this._editor.getBottomForLineNumber(r.range.endLineNumberExclusive-1,!0)-t))-a;o.domNode.style.top=`${a}px`,o.domNode.style.height=`${c}px`,o.gutterItemView.layout(L.L.ofStartAndLength(a,c),n)}}))}for(const r of s){const e=this.views.get(r);e.gutterItemView.dispose(),e.domNode.remove(),this.views.delete(r)}}}class Ge{constructor(e,t,i){this.item=e,this.gutterItemView=t,this.domNode=i}}var je=i(25791),Ke=i(75295),Ye=i(50973);class qe extends Ke.CO{constructor(e){super(),this._textModel=e}getValueOfRange(e){return this._textModel.getValueInRange(e)}get length(){const e=this._textModel.getLineCount(),t=this._textModel.getLineLength(e);return new Ye.W(e-1,t)}}var $e=i(65644),Qe=i(27195),Xe=i(32848),Ze=i(67220),Je=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},et=function(e,t){return function(i,s){t(i,s,e)}};const tt=[];let it=class extends a.jG{constructor(e,t,i,n,r,o,a,h,d){super(),this._diffModel=t,this._editors=i,this._options=n,this._sashLayout=r,this._boundarySashes=o,this._instantiationService=a,this._contextKeyService=h,this._menuService=d,this._menu=this._register(this._menuService.createMenu(Qe.D8.DiffEditorHunkToolbar,this._contextKeyService)),this._actions=(0,l.y0)(this,this._menu.onDidChange,(()=>this._menu.getActions())),this._hasActions=this._actions.map((e=>e.length>0)),this._showSash=(0,l.un)(this,(e=>this._options.renderSideBySide.read(e)&&this._hasActions.read(e))),this.width=(0,l.un)(this,(e=>this._hasActions.read(e)?35:0)),this.elements=(0,s.h)("div.gutter@gutter",{style:{position:"absolute",height:"100%",width:"35px"}},[]),this._currentDiff=(0,l.un)(this,(e=>{const t=this._diffModel.read(e);if(!t)return;const i=t.diff.read(e)?.mappings,s=this._editors.modifiedCursor.read(e);return s?i?.find((e=>e.lineRangeMapping.modified.contains(s.lineNumber))):void 0})),this._selectedDiffs=(0,l.un)(this,(e=>{const t=this._diffModel.read(e),i=t?.diff.read(e);if(!i)return tt;const s=this._editors.modifiedSelections.read(e);if(s.every((e=>e.isEmpty())))return tt;const n=new w.S(s.map((e=>w.M.fromRangeInclusive(e)))),r=i.mappings.filter((e=>e.lineRangeMapping.innerChanges&&n.intersects(e.lineRangeMapping.modified))).map((e=>({mapping:e,rangeMappings:e.lineRangeMapping.innerChanges.filter((e=>s.some((t=>T.Q.areIntersecting(e.modifiedRange,t)))))})));return 0===r.length||r.every((e=>0===e.rangeMappings.length))?tt:r})),this._register((0,S.$y)(e,this.elements.root)),this._register((0,s.ko)(this.elements.root,"click",(()=>{this._editors.modified.focus()}))),this._register((0,S.AV)(this.elements.root,{display:this._hasActions.map((e=>e?"block":"none"))})),(0,c.a0)(this,(t=>this._showSash.read(t)?new Ve(e,this._sashLayout.dimensions,this._options.enableSplitViewResizing,this._boundarySashes,(0,c.dQ)(this,(e=>this._sashLayout.sashLeft.read(e)-35),((e,t)=>this._sashLayout.sashLeft.set(e+35,t))),(()=>this._sashLayout.resetSash())):void 0)).recomputeInitiallyAndOnChange(this._store),this._register(new ze(this._editors.modified,this.elements.root,{getIntersectingGutterItems:(e,t)=>{const i=this._diffModel.read(t);if(!i)return[];const s=i.diff.read(t);if(!s)return[];const n=this._selectedDiffs.read(t);if(n.length>0){const e=x.wm.fromRangeMappings(n.flatMap((e=>e.rangeMappings)));return[new st(e,!0,Qe.D8.DiffEditorSelectionToolbar,void 0,i.model.original.uri,i.model.modified.uri)]}const r=this._currentDiff.read(t);return s.mappings.map((e=>new st(e.lineRangeMapping.withInnerChangesFromLineRanges(),e.lineRangeMapping===r?.lineRangeMapping,Qe.D8.DiffEditorHunkToolbar,void 0,i.model.original.uri,i.model.modified.uri)))},createView:(e,t)=>this._instantiationService.createInstance(nt,e,t,this)})),this._register((0,s.ko)(this.elements.gutter,s.Bx.MOUSE_WHEEL,(e=>{this._editors.modified.getOption(104).handleMouseWheel&&this._editors.modified.delegateScrollFromMouseWheelEvent(e)}),{passive:!1}))}computeStagedValue(e){const t=e.innerChanges??[],i=new qe(this._editors.modifiedModel.get()),s=new qe(this._editors.original.getModel()),n=new Ke.mF(t.map((e=>e.toTextEdit(i))));return n.apply(s)}layout(e){this.elements.gutter.style.left=e+"px"}};it=Je([et(6,M._Y),et(7,Xe.fN),et(8,Qe.ez)],it);class st{constructor(e,t,i,s,n,r){this.mapping=e,this.showAlways=t,this.menuId=i,this.rangeOverride=s,this.originalUri=n,this.modifiedUri=r}get id(){return this.mapping.modified.toString()}get range(){return this.rangeOverride??this.mapping.modified}}let nt=class extends a.jG{constructor(e,t,i,n){super(),this._item=e,this._elements=(0,s.h)("div.gutterItem",{style:{height:"20px",width:"34px"}},[(0,s.h)("div.background@background",{},[]),(0,s.h)("div.buttons@buttons",{},[])]),this._showAlways=this._item.map(this,(e=>e.showAlways)),this._menuId=this._item.map(this,(e=>e.menuId)),this._isSmall=(0,l.FY)(this,!1),this._lastItemRange=void 0,this._lastViewRange=void 0;const r=this._register(n.createInstance(Ze.fO,"element",!0,{position:{hoverPosition:1}}));this._register((0,S.rX)(t,this._elements.root)),this._register((0,l.fm)((e=>{const t=this._showAlways.read(e);this._elements.root.classList.toggle("noTransition",!0),this._elements.root.classList.toggle("showAlways",t),setTimeout((()=>{this._elements.root.classList.toggle("noTransition",!1)}),0)}))),this._register((0,l.yC)(((e,t)=>{this._elements.buttons.replaceChildren();const s=t.add(n.createInstance($e.m,this._elements.buttons,this._menuId.read(e),{orientation:1,hoverDelegate:r,toolbarOptions:{primaryGroup:e=>e.startsWith("primary")},overflowBehavior:{maxItems:this._isSmall.read(e)?1:3},hiddenItemStrategy:0,actionRunner:new je.I((()=>{const e=this._item.get(),t=e.mapping;return{mapping:t,originalWithModifiedChanges:i.computeStagedValue(t),originalUri:e.originalUri,modifiedUri:e.modifiedUri}})),menuOptions:{shouldForwardArgs:!0}}));t.add(s.onDidChangeMenuItems((()=>{this._lastItemRange&&this.layout(this._lastItemRange,this._lastViewRange)})))})))}layout(e,t){this._lastItemRange=e,this._lastViewRange=t;let i=this._elements.buttons.clientHeight;this._isSmall.set(1===this._item.get().mapping.original.startLineNumber&&e.length<30,void 0),i=this._elements.buttons.clientHeight;const s=e.length/2-i/2,n=i;let r=e.start+s;const o=L.L.tryCreate(n,t.endExclusive-n-i),a=L.L.tryCreate(e.start+n,e.endExclusive-i-n);a&&o&&a.start=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},gt=function(e,t){return function(i,s){t(i,s,e)}};let pt=class extends a.jG{static{rt=this}static{this.ONE_OVERVIEW_WIDTH=15}static{this.ENTIRE_DIFF_OVERVIEW_WIDTH=2*this.ONE_OVERVIEW_WIDTH}constructor(e,t,i,n,r,o,a){super(),this._editors=e,this._rootElement=t,this._diffModel=i,this._rootWidth=n,this._rootHeight=r,this._modifiedEditorLayoutInfo=o,this._themeService=a,this.width=rt.ENTIRE_DIFF_OVERVIEW_WIDTH;const c=(0,l.y0)(this._themeService.onDidColorThemeChange,(()=>this._themeService.getColorTheme())),h=(0,l.un)((e=>{const t=c.read(e);return{insertColor:t.getColor(ht.ld8)||(t.getColor(ht.Gj6)||ht.EY1).transparent(2),removeColor:t.getColor(ht.$BZ)||(t.getColor(ht.GNm)||ht.ZEf).transparent(2)}})),d=(0,at.Z)(document.createElement("div"));d.setClassName("diffViewport"),d.setPosition("absolute");const u=(0,s.h)("div.diffOverview",{style:{position:"absolute",top:"0px",width:rt.ENTIRE_DIFF_OVERVIEW_WIDTH+"px"}}).root;this._register((0,S.rX)(u,d.domNode)),this._register((0,s.b2)(u,s.Bx.POINTER_DOWN,(e=>{this._editors.modified.delegateVerticalScrollbarPointerDown(e)}))),this._register((0,s.ko)(u,s.Bx.MOUSE_WHEEL,(e=>{this._editors.modified.delegateScrollFromMouseWheelEvent(e)}),{passive:!1})),this._register((0,S.rX)(this._rootElement,u)),this._register((0,l.yC)(((e,t)=>{const i=this._diffModel.read(e),s=this._editors.original.createOverviewRuler("original diffOverviewRuler");s&&(t.add(s),t.add((0,S.rX)(u,s.getDomNode())));const n=this._editors.modified.createOverviewRuler("modified diffOverviewRuler");if(n&&(t.add(n),t.add((0,S.rX)(u,n.getDomNode()))),!s||!n)return;const r=(0,l.yQ)("viewZoneChanged",this._editors.original.onDidChangeViewZones),o=(0,l.yQ)("viewZoneChanged",this._editors.modified.onDidChangeViewZones),a=(0,l.yQ)("hiddenRangesChanged",this._editors.original.onDidChangeHiddenAreas),c=(0,l.yQ)("hiddenRangesChanged",this._editors.modified.onDidChangeHiddenAreas);t.add((0,l.fm)((e=>{r.read(e),o.read(e),a.read(e),c.read(e);const t=h.read(e),l=i?.diff.read(e)?.mappings;function d(e,t,i){const s=i._getViewModel();return s?e.filter((e=>e.length>0)).map((e=>{const i=s.coordinatesConverter.convertModelPositionToViewPosition(new R.y(e.startLineNumber,1)),n=s.coordinatesConverter.convertModelPositionToViewPosition(new R.y(e.endLineNumberExclusive,1)),r=n.lineNumber-i.lineNumber;return new ct.iE(i.lineNumber,n.lineNumber,r,t.toString())})):[]}const u=d((l||[]).map((e=>e.lineRangeMapping.original)),t.removeColor,this._editors.original),g=d((l||[]).map((e=>e.lineRangeMapping.modified)),t.insertColor,this._editors.modified);s?.setZones(u),n?.setZones(g)}))),t.add((0,l.fm)((e=>{const t=this._rootHeight.read(e),i=this._rootWidth.read(e),r=this._modifiedEditorLayoutInfo.read(e);if(r){const i=rt.ENTIRE_DIFF_OVERVIEW_WIDTH-2*rt.ONE_OVERVIEW_WIDTH;s.setLayout({top:0,height:t,right:i+rt.ONE_OVERVIEW_WIDTH,width:rt.ONE_OVERVIEW_WIDTH}),n.setLayout({top:0,height:t,right:0,width:rt.ONE_OVERVIEW_WIDTH});const o=this._editors.modifiedScrollTop.read(e),a=this._editors.modifiedScrollHeight.read(e),l=this._editors.modified.getOption(104),c=new lt.m(l.verticalHasArrows?l.arrowSize:0,l.verticalScrollbarSize,0,r.height,a,o);d.setTop(c.getSliderPosition()),d.setHeight(c.getSliderSize())}else d.setTop(0),d.setHeight(0);u.style.height=t+"px",u.style.left=i-rt.ENTIRE_DIFF_OVERVIEW_WIDTH+"px",d.setWidth(rt.ENTIRE_DIFF_OVERVIEW_WIDTH)})))})))}};pt=rt=ut([gt(6,dt.Gy)],pt);var mt=i(20370),ft=i(16223);const _t=[];class vt extends a.jG{constructor(e,t,i,s){super(),this._editors=e,this._diffModel=t,this._options=i,this._widget=s,this._selectedDiffs=(0,l.un)(this,(e=>{const t=this._diffModel.read(e),i=t?.diff.read(e);if(!i)return _t;const s=this._editors.modifiedSelections.read(e);if(s.every((e=>e.isEmpty())))return _t;const n=new w.S(s.map((e=>w.M.fromRangeInclusive(e)))),r=i.mappings.filter((e=>e.lineRangeMapping.innerChanges&&n.intersects(e.lineRangeMapping.modified))).map((e=>({mapping:e,rangeMappings:e.lineRangeMapping.innerChanges.filter((e=>s.some((t=>T.Q.areIntersecting(e.modifiedRange,t)))))})));return 0===r.length||r.every((e=>0===e.rangeMappings.length))?_t:r})),this._register((0,l.yC)(((e,t)=>{if(!this._options.shouldRenderOldRevertArrows.read(e))return;const i=this._diffModel.read(e),s=i?.diff.read(e);if(!i||!s)return;if(i.movedTextToCompare.read(e))return;const n=[],r=this._selectedDiffs.read(e),o=new Set(r.map((e=>e.mapping)));if(r.length>0){const i=this._editors.modifiedSelections.read(e),s=t.add(new Ct(i[i.length-1].positionLineNumber,this._widget,r.flatMap((e=>e.rangeMappings)),!0));this._editors.modified.addGlyphMarginWidget(s),n.push(s)}for(const a of s.mappings)if(!o.has(a)&&!a.lineRangeMapping.modified.isEmpty&&a.lineRangeMapping.innerChanges){const e=t.add(new Ct(a.lineRangeMapping.modified.startLineNumber,this._widget,a.lineRangeMapping,!1));this._editors.modified.addGlyphMarginWidget(e),n.push(e)}t.add((0,a.s)((()=>{for(const e of n)this._editors.modified.removeGlyphMarginWidget(e)})))})))}}class Ct extends a.jG{static{this.counter=0}getId(){return this._id}constructor(e,t,i,n){super(),this._lineNumber=e,this._widget=t,this._diffs=i,this._revertSelection=n,this._id="revertButton"+Ct.counter++,this._domNode=(0,s.h)("div.revertButton",{title:this._revertSelection?(0,O.kg)("revertSelectedChanges","Revert Selected Changes"):(0,O.kg)("revertChange","Revert Change")},[(0,mt.s)(C.W.arrowRight)]).root,this._register((0,s.ko)(this._domNode,s.Bx.MOUSE_DOWN,(e=>{2!==e.button&&(e.stopPropagation(),e.preventDefault())}))),this._register((0,s.ko)(this._domNode,s.Bx.MOUSE_UP,(e=>{e.stopPropagation(),e.preventDefault()}))),this._register((0,s.ko)(this._domNode,s.Bx.CLICK,(e=>{this._diffs instanceof x.WL?this._widget.revert(this._diffs):this._widget.revertRangeMappings(this._diffs),e.stopPropagation(),e.preventDefault()})))}getDomNode(){return this._domNode}getPosition(){return{lane:ft.ZS.Right,range:{startColumn:1,startLineNumber:this._lineNumber,endColumn:1,endLineNumber:this._lineNumber},zIndex:10001}}}var bt=i(71319),Et=i(23452),St=i(60002),yt=i(58345),wt=i(73823),Lt=i(38844),Rt=i(98031),Tt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xt=function(e,t){return function(i,s){t(i,s,e)}};let kt=class extends a.jG{get onDidContentSizeChange(){return this._onDidContentSizeChange.event}constructor(e,t,i,s,n,r,a){super(),this.originalEditorElement=e,this.modifiedEditorElement=t,this._options=i,this._argCodeEditorWidgetOptions=s,this._createInnerEditor=n,this._instantiationService=r,this._keybindingService=a,this.original=this._register(this._createLeftHandSideEditor(this._options.editorOptions.get(),this._argCodeEditorWidgetOptions.originalEditor||{})),this.modified=this._register(this._createRightHandSideEditor(this._options.editorOptions.get(),this._argCodeEditorWidgetOptions.modifiedEditor||{})),this._onDidContentSizeChange=this._register(new o.vl),this.modifiedScrollTop=(0,l.y0)(this,this.modified.onDidScrollChange,(()=>this.modified.getScrollTop())),this.modifiedScrollHeight=(0,l.y0)(this,this.modified.onDidScrollChange,(()=>this.modified.getScrollHeight())),this.modifiedObs=(0,Lt.Ud)(this.modified),this.originalObs=(0,Lt.Ud)(this.original),this.modifiedModel=this.modifiedObs.model,this.modifiedSelections=(0,l.y0)(this,this.modified.onDidChangeCursorSelection,(()=>this.modified.getSelections()??[])),this.modifiedCursor=(0,l.C)({owner:this,equalsFn:R.y.equals},(e=>this.modifiedSelections.read(e)[0]?.getPosition()??new R.y(1,1))),this.originalCursor=(0,l.y0)(this,this.original.onDidChangeCursorPosition,(()=>this.original.getPosition()??new R.y(1,1))),this._argCodeEditorWidgetOptions=null,this._register((0,l.Y)({createEmptyChangeSummary:()=>({}),handleChange:(e,t)=>(e.didChange(i.editorOptions)&&Object.assign(t,e.change.changedOptions),!0)},((e,t)=>{i.editorOptions.read(e),this._options.renderSideBySide.read(e),this.modified.updateOptions(this._adjustOptionsForRightHandSide(e,t)),this.original.updateOptions(this._adjustOptionsForLeftHandSide(e,t))})))}_createLeftHandSideEditor(e,t){const i=this._adjustOptionsForLeftHandSide(void 0,e),s=this._constructInnerEditor(this._instantiationService,this.originalEditorElement,i,t);return s.setContextValue("isInDiffLeftEditor",!0),s}_createRightHandSideEditor(e,t){const i=this._adjustOptionsForRightHandSide(void 0,e),s=this._constructInnerEditor(this._instantiationService,this.modifiedEditorElement,i,t);return s.setContextValue("isInDiffRightEditor",!0),s}_constructInnerEditor(e,t,i,s){const n=this._createInnerEditor(e,t,i,s);return this._register(n.onDidContentSizeChange((e=>{const t=this.original.getContentWidth()+this.modified.getContentWidth()+pt.ENTIRE_DIFF_OVERVIEW_WIDTH,i=Math.max(this.modified.getContentHeight(),this.original.getContentHeight());this._onDidContentSizeChange.fire({contentHeight:i,contentWidth:t,contentHeightChanged:e.contentHeightChanged,contentWidthChanged:e.contentWidthChanged})}))),n}_adjustOptionsForLeftHandSide(e,t){const i=this._adjustOptionsForSubEditor(t);return this._options.renderSideBySide.get()?(i.unicodeHighlight=this._options.editorOptions.get().unicodeHighlight||{},i.wordWrapOverride1=this._options.diffWordWrap.get()):(i.wordWrapOverride1="off",i.wordWrapOverride2="off",i.stickyScroll={enabled:!1},i.unicodeHighlight={nonBasicASCII:!1,ambiguousCharacters:!1,invisibleCharacters:!1}),i.glyphMargin=this._options.renderSideBySide.get(),t.originalAriaLabel&&(i.ariaLabel=t.originalAriaLabel),i.ariaLabel=this._updateAriaLabel(i.ariaLabel),i.readOnly=!this._options.originalEditable.get(),i.dropIntoEditor={enabled:!i.readOnly},i.extraEditorClassName="original-in-monaco-diff-editor",i}_adjustOptionsForRightHandSide(e,t){const i=this._adjustOptionsForSubEditor(t);return t.modifiedAriaLabel&&(i.ariaLabel=t.modifiedAriaLabel),i.ariaLabel=this._updateAriaLabel(i.ariaLabel),i.wordWrapOverride1=this._options.diffWordWrap.get(),i.revealHorizontalRightPadding=y.qB.revealHorizontalRightPadding.defaultValue+pt.ENTIRE_DIFF_OVERVIEW_WIDTH,i.scrollbar.verticalHasArrows=!1,i.extraEditorClassName="modified-in-monaco-diff-editor",i}_adjustOptionsForSubEditor(e){const t={...e,dimension:{height:0,width:0}};return t.inDiffEditor=!0,t.automaticLayout=!1,t.scrollbar={...t.scrollbar||{}},t.folding=!1,t.codeLens=this._options.diffCodeLens.get(),t.fixedOverflowWidgets=!0,t.minimap={...t.minimap||{}},t.minimap.enabled=!1,this._options.hideUnchangedRegions.get()?t.stickyScroll={enabled:!1}:t.stickyScroll=this._options.editorOptions.get().stickyScroll,t}_updateAriaLabel(e){e||(e="");const t=(0,O.kg)("diff-aria-navigation-tip"," use {0} to open the accessibility help.",this._keybindingService.lookupKeybinding("editor.action.accessibilityHelp")?.getAriaLabel());return this._options.accessibilityVerbose.get()?e+t:e?e.replaceAll(t,""):""}};kt=Tt([xt(5,M._Y),xt(6,Rt.b)],kt);class At extends a.jG{constructor(){super(...arguments),this._id=++At.idCounter,this._onDidDispose=this._register(new o.vl),this.onDidDispose=this._onDidDispose.event}static{this.idCounter=0}getId(){return this.getEditorType()+":v2:"+this._id}getVisibleColumnFromPosition(e){return this._targetEditor.getVisibleColumnFromPosition(e)}getPosition(){return this._targetEditor.getPosition()}setPosition(e,t="api"){this._targetEditor.setPosition(e,t)}revealLine(e,t=0){this._targetEditor.revealLine(e,t)}revealLineInCenter(e,t=0){this._targetEditor.revealLineInCenter(e,t)}revealLineInCenterIfOutsideViewport(e,t=0){this._targetEditor.revealLineInCenterIfOutsideViewport(e,t)}revealLineNearTop(e,t=0){this._targetEditor.revealLineNearTop(e,t)}revealPosition(e,t=0){this._targetEditor.revealPosition(e,t)}revealPositionInCenter(e,t=0){this._targetEditor.revealPositionInCenter(e,t)}revealPositionInCenterIfOutsideViewport(e,t=0){this._targetEditor.revealPositionInCenterIfOutsideViewport(e,t)}revealPositionNearTop(e,t=0){this._targetEditor.revealPositionNearTop(e,t)}getSelection(){return this._targetEditor.getSelection()}getSelections(){return this._targetEditor.getSelections()}setSelection(e,t="api"){this._targetEditor.setSelection(e,t)}setSelections(e,t="api"){this._targetEditor.setSelections(e,t)}revealLines(e,t,i=0){this._targetEditor.revealLines(e,t,i)}revealLinesInCenter(e,t,i=0){this._targetEditor.revealLinesInCenter(e,t,i)}revealLinesInCenterIfOutsideViewport(e,t,i=0){this._targetEditor.revealLinesInCenterIfOutsideViewport(e,t,i)}revealLinesNearTop(e,t,i=0){this._targetEditor.revealLinesNearTop(e,t,i)}revealRange(e,t=0,i=!1,s=!0){this._targetEditor.revealRange(e,t,i,s)}revealRangeInCenter(e,t=0){this._targetEditor.revealRangeInCenter(e,t)}revealRangeInCenterIfOutsideViewport(e,t=0){this._targetEditor.revealRangeInCenterIfOutsideViewport(e,t)}revealRangeNearTop(e,t=0){this._targetEditor.revealRangeNearTop(e,t)}revealRangeNearTopIfOutsideViewport(e,t=0){this._targetEditor.revealRangeNearTopIfOutsideViewport(e,t)}revealRangeAtTop(e,t=0){this._targetEditor.revealRangeAtTop(e,t)}getSupportedActions(){return this._targetEditor.getSupportedActions()}focus(){this._targetEditor.focus()}trigger(e,t,i){this._targetEditor.trigger(e,t,i)}createDecorationsCollection(e){return this._targetEditor.createDecorationsCollection(e)}changeDecorations(e){return this._targetEditor.changeDecorations(e)}}var Nt=i(13850),It=i(61059),Ot=i(253),Dt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Mt=function(e,t){return function(i,s){t(i,s,e)}};let Pt=class{get editorOptions(){return this._options}constructor(e,t){this._accessibilityService=t,this._diffEditorWidth=(0,l.FY)(this,0),this._screenReaderMode=(0,l.y0)(this,this._accessibilityService.onDidChangeScreenReaderOptimized,(()=>this._accessibilityService.isScreenReaderOptimized())),this.couldShowInlineViewBecauseOfSize=(0,l.un)(this,(e=>this._options.read(e).renderSideBySide&&this._diffEditorWidth.read(e)<=this._options.read(e).renderSideBySideInlineBreakpoint)),this.renderOverviewRuler=(0,l.un)(this,(e=>this._options.read(e).renderOverviewRuler)),this.renderSideBySide=(0,l.un)(this,(e=>(!this.compactMode.read(e)||!this.shouldRenderInlineViewInSmartMode.read(e))&&(this._options.read(e).renderSideBySide&&!(this._options.read(e).useInlineViewWhenSpaceIsLimited&&this.couldShowInlineViewBecauseOfSize.read(e)&&!this._screenReaderMode.read(e))))),this.readOnly=(0,l.un)(this,(e=>this._options.read(e).readOnly)),this.shouldRenderOldRevertArrows=(0,l.un)(this,(e=>!!this._options.read(e).renderMarginRevertIcon&&(!!this.renderSideBySide.read(e)&&(!this.readOnly.read(e)&&!this.shouldRenderGutterMenu.read(e))))),this.shouldRenderGutterMenu=(0,l.un)(this,(e=>this._options.read(e).renderGutterMenu)),this.renderIndicators=(0,l.un)(this,(e=>this._options.read(e).renderIndicators)),this.enableSplitViewResizing=(0,l.un)(this,(e=>this._options.read(e).enableSplitViewResizing)),this.splitViewDefaultRatio=(0,l.un)(this,(e=>this._options.read(e).splitViewDefaultRatio)),this.ignoreTrimWhitespace=(0,l.un)(this,(e=>this._options.read(e).ignoreTrimWhitespace)),this.maxComputationTimeMs=(0,l.un)(this,(e=>this._options.read(e).maxComputationTime)),this.showMoves=(0,l.un)(this,(e=>this._options.read(e).experimental.showMoves&&this.renderSideBySide.read(e))),this.isInEmbeddedEditor=(0,l.un)(this,(e=>this._options.read(e).isInEmbeddedEditor)),this.diffWordWrap=(0,l.un)(this,(e=>this._options.read(e).diffWordWrap)),this.originalEditable=(0,l.un)(this,(e=>this._options.read(e).originalEditable)),this.diffCodeLens=(0,l.un)(this,(e=>this._options.read(e).diffCodeLens)),this.accessibilityVerbose=(0,l.un)(this,(e=>this._options.read(e).accessibilityVerbose)),this.diffAlgorithm=(0,l.un)(this,(e=>this._options.read(e).diffAlgorithm)),this.showEmptyDecorations=(0,l.un)(this,(e=>this._options.read(e).experimental.showEmptyDecorations)),this.onlyShowAccessibleDiffViewer=(0,l.un)(this,(e=>this._options.read(e).onlyShowAccessibleDiffViewer)),this.compactMode=(0,l.un)(this,(e=>this._options.read(e).compactMode)),this.trueInlineDiffRenderingEnabled=(0,l.un)(this,(e=>this._options.read(e).experimental.useTrueInlineView)),this.useTrueInlineDiffRendering=(0,l.un)(this,(e=>!this.renderSideBySide.read(e)&&this.trueInlineDiffRenderingEnabled.read(e))),this.hideUnchangedRegions=(0,l.un)(this,(e=>this._options.read(e).hideUnchangedRegions.enabled)),this.hideUnchangedRegionsRevealLineCount=(0,l.un)(this,(e=>this._options.read(e).hideUnchangedRegions.revealLineCount)),this.hideUnchangedRegionsContextLineCount=(0,l.un)(this,(e=>this._options.read(e).hideUnchangedRegions.contextLineCount)),this.hideUnchangedRegionsMinimumLineCount=(0,l.un)(this,(e=>this._options.read(e).hideUnchangedRegions.minimumLineCount)),this._model=(0,l.FY)(this,void 0),this.shouldRenderInlineViewInSmartMode=this._model.map(this,(e=>(0,Nt.t)(this,(t=>{const i=e?.diff.read(t);return i?(s=i,n=this.trueInlineDiffRenderingEnabled.read(t),s.mappings.every((e=>0===e.lineRangeMapping.original.length||function(e){return 0===e.modified.length}(e.lineRangeMapping)||n&&De(e.lineRangeMapping)))):void 0;var s,n})))).flatten().map(this,(e=>!!e)),this.inlineViewHideOriginalLineNumbers=this.compactMode;const i={...e,...Ft(e,It.q)};this._options=(0,l.FY)(this,i)}updateOptions(e){const t=Ft(e,this._options.get()),i={...this._options.get(),...e,...t};this._options.set(i,void 0,{changedOptions:e})}setWidth(e){this._diffEditorWidth.set(e,void 0)}setModel(e){this._model.set(e,void 0)}};function Ft(e,t){return{enableSplitViewResizing:(0,y.zM)(e.enableSplitViewResizing,t.enableSplitViewResizing),splitViewDefaultRatio:(0,y.ls)(e.splitViewDefaultRatio,.5,.1,.9),renderSideBySide:(0,y.zM)(e.renderSideBySide,t.renderSideBySide),renderMarginRevertIcon:(0,y.zM)(e.renderMarginRevertIcon,t.renderMarginRevertIcon),maxComputationTime:(0,y.wA)(e.maxComputationTime,t.maxComputationTime,0,1073741824),maxFileSize:(0,y.wA)(e.maxFileSize,t.maxFileSize,0,1073741824),ignoreTrimWhitespace:(0,y.zM)(e.ignoreTrimWhitespace,t.ignoreTrimWhitespace),renderIndicators:(0,y.zM)(e.renderIndicators,t.renderIndicators),originalEditable:(0,y.zM)(e.originalEditable,t.originalEditable),diffCodeLens:(0,y.zM)(e.diffCodeLens,t.diffCodeLens),renderOverviewRuler:(0,y.zM)(e.renderOverviewRuler,t.renderOverviewRuler),diffWordWrap:(0,y.O4)(e.diffWordWrap,t.diffWordWrap,["off","on","inherit"]),diffAlgorithm:(0,y.O4)(e.diffAlgorithm,t.diffAlgorithm,["legacy","advanced"],{smart:"legacy",experimental:"advanced"}),accessibilityVerbose:(0,y.zM)(e.accessibilityVerbose,t.accessibilityVerbose),experimental:{showMoves:(0,y.zM)(e.experimental?.showMoves,t.experimental.showMoves),showEmptyDecorations:(0,y.zM)(e.experimental?.showEmptyDecorations,t.experimental.showEmptyDecorations),useTrueInlineView:(0,y.zM)(e.experimental?.useTrueInlineView,t.experimental.useTrueInlineView)},hideUnchangedRegions:{enabled:(0,y.zM)(e.hideUnchangedRegions?.enabled??e.experimental?.collapseUnchangedRegions,t.hideUnchangedRegions.enabled),contextLineCount:(0,y.wA)(e.hideUnchangedRegions?.contextLineCount,t.hideUnchangedRegions.contextLineCount,0,1073741824),minimumLineCount:(0,y.wA)(e.hideUnchangedRegions?.minimumLineCount,t.hideUnchangedRegions.minimumLineCount,0,1073741824),revealLineCount:(0,y.wA)(e.hideUnchangedRegions?.revealLineCount,t.hideUnchangedRegions.revealLineCount,0,1073741824)},isInEmbeddedEditor:(0,y.zM)(e.isInEmbeddedEditor,t.isInEmbeddedEditor),onlyShowAccessibleDiffViewer:(0,y.zM)(e.onlyShowAccessibleDiffViewer,t.onlyShowAccessibleDiffViewer),renderSideBySideInlineBreakpoint:(0,y.wA)(e.renderSideBySideInlineBreakpoint,t.renderSideBySideInlineBreakpoint,0,1073741824),useInlineViewWhenSpaceIsLimited:(0,y.zM)(e.useInlineViewWhenSpaceIsLimited,t.useInlineViewWhenSpaceIsLimited),renderGutterMenu:(0,y.zM)(e.renderGutterMenu,t.renderGutterMenu),compactMode:(0,y.zM)(e.compactMode,t.compactMode)}}Pt=Dt([Mt(1,Ot.j)],Pt);var Ut=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ht=function(e,t){return function(i,s){t(i,s,e)}};let Bt=class extends At{get onDidContentSizeChange(){return this._editors.onDidContentSizeChange}constructor(e,t,i,n,h,d,g,p){super(),this._domElement=e,this._parentContextKeyService=n,this._parentInstantiationService=h,this._accessibilitySignalService=g,this._editorProgressService=p,this.elements=(0,s.h)("div.monaco-diff-editor.side-by-side",{style:{position:"relative",height:"100%"}},[(0,s.h)("div.editor.original@original",{style:{position:"absolute",height:"100%"}}),(0,s.h)("div.editor.modified@modified",{style:{position:"absolute",height:"100%"}}),(0,s.h)("div.accessibleDiffViewer@accessibleDiffViewer",{style:{position:"absolute",height:"100%"}})]),this._diffModelSrc=this._register((0,l.X2)(this,void 0)),this._diffModel=(0,l.un)(this,(e=>this._diffModelSrc.read(e)?.object)),this.onDidChangeModel=o.Jh.fromObservableLight(this._diffModel),this._contextKeyService=this._register(this._parentContextKeyService.createScoped(this._domElement)),this._instantiationService=this._register(this._parentInstantiationService.createChild(new yt.a([Xe.fN,this._contextKeyService]))),this._boundarySashes=(0,l.FY)(this,void 0),this._accessibleDiffViewerShouldBeVisible=(0,l.FY)(this,!1),this._accessibleDiffViewerVisible=(0,l.un)(this,(e=>!!this._options.onlyShowAccessibleDiffViewer.read(e)||this._accessibleDiffViewerShouldBeVisible.read(e))),this._movedBlocksLinesPart=(0,l.FY)(this,void 0),this._layoutInfo=(0,l.un)(this,(e=>{const t=this._rootSizeObserver.width.read(e),i=this._rootSizeObserver.height.read(e);this._rootSizeObserver.automaticLayout?this.elements.root.style.height="100%":this.elements.root.style.height=i+"px";const s=this._sash.read(e),n=this._gutter.read(e),r=n?.width.read(e)??0,o=this._overviewRulerPart.read(e)?.width??0;let a,l,c,h,d;if(!!s){const i=s.sashLeft.read(e);a=0,l=i-r-(this._movedBlocksLinesPart.read(e)?.width.read(e)??0),d=i-r,c=i,h=t-c-o}else{d=0;a=r,l=this._options.inlineViewHideOriginalLineNumbers.read(e)?0:Math.max(5,this._editors.originalObs.layoutInfoDecorationsLeft.read(e)),c=r+l,h=t-c-o}return this.elements.original.style.left=a+"px",this.elements.original.style.width=l+"px",this._editors.original.layout({width:l,height:i},!0),n?.layout(d),this.elements.modified.style.left=c+"px",this.elements.modified.style.width=h+"px",this._editors.modified.layout({width:h,height:i},!0),{modifiedEditor:this._editors.modified.getLayoutInfo(),originalEditor:this._editors.original.getLayoutInfo()}})),this._diffValue=this._diffModel.map(((e,t)=>e?.diff.read(t))),this.onDidUpdateDiff=o.Jh.fromObservableLight(this._diffValue),d.willCreateDiffEditor(),this._contextKeyService.createKey("isInDiffEditor",!0),this._domElement.appendChild(this.elements.root),this._register((0,a.s)((()=>this.elements.root.remove()))),this._rootSizeObserver=this._register(new S.pN(this.elements.root,t.dimension)),this._rootSizeObserver.setAutomaticLayout(t.automaticLayout??!1),this._options=this._instantiationService.createInstance(Pt,t),this._register((0,l.fm)((e=>{this._options.setWidth(this._rootSizeObserver.width.read(e))}))),this._contextKeyService.createKey(St.R.isEmbeddedDiffEditor.key,!1),this._register((0,bt.w)(St.R.isEmbeddedDiffEditor,this._contextKeyService,(e=>this._options.isInEmbeddedEditor.read(e)))),this._register((0,bt.w)(St.R.comparingMovedCode,this._contextKeyService,(e=>!!this._diffModel.read(e)?.movedTextToCompare.read(e)))),this._register((0,bt.w)(St.R.diffEditorRenderSideBySideInlineBreakpointReached,this._contextKeyService,(e=>this._options.couldShowInlineViewBecauseOfSize.read(e)))),this._register((0,bt.w)(St.R.diffEditorInlineMode,this._contextKeyService,(e=>!this._options.renderSideBySide.read(e)))),this._register((0,bt.w)(St.R.hasChanges,this._contextKeyService,(e=>(this._diffModel.read(e)?.diff.read(e)?.mappings.length??0)>0))),this._editors=this._register(this._instantiationService.createInstance(kt,this.elements.original,this.elements.modified,this._options,i,((e,t,i,s)=>this._createInnerEditor(e,t,i,s)))),this._register((0,bt.w)(St.R.diffEditorOriginalWritable,this._contextKeyService,(e=>this._options.originalEditable.read(e)))),this._register((0,bt.w)(St.R.diffEditorModifiedWritable,this._contextKeyService,(e=>!this._options.readOnly.read(e)))),this._register((0,bt.w)(St.R.diffEditorOriginalUri,this._contextKeyService,(e=>this._diffModel.read(e)?.model.original.uri.toString()??""))),this._register((0,bt.w)(St.R.diffEditorModifiedUri,this._contextKeyService,(e=>this._diffModel.read(e)?.model.modified.uri.toString()??""))),this._overviewRulerPart=(0,c.a0)(this,(e=>this._options.renderOverviewRuler.read(e)?this._instantiationService.createInstance((0,ne.b)(pt,e),this._editors,this.elements.root,this._diffModel,this._rootSizeObserver.width,this._rootSizeObserver.height,this._layoutInfo.map((e=>e.modifiedEditor))):void 0)).recomputeInitiallyAndOnChange(this._store);const m={height:this._rootSizeObserver.height,width:this._rootSizeObserver.width.map(((e,t)=>e-(this._overviewRulerPart.read(t)?.width??0)))};this._sashLayout=new We(this._options,m),this._sash=(0,c.a0)(this,(e=>{const t=this._options.renderSideBySide.read(e);return this.elements.root.classList.toggle("side-by-side",t),t?new Ve(this.elements.root,m,this._options.enableSplitViewResizing,this._boundarySashes,this._sashLayout.sashLeft,(()=>this._sashLayout.resetSash())):void 0})).recomputeInitiallyAndOnChange(this._store);const f=(0,c.a0)(this,(e=>this._instantiationService.createInstance((0,ne.b)(ot.N,e),this._editors,this._diffModel,this._options))).recomputeInitiallyAndOnChange(this._store);(0,c.a0)(this,(e=>this._instantiationService.createInstance((0,ne.b)(He,e),this._editors,this._diffModel,this._options,this))).recomputeInitiallyAndOnChange(this._store);const _=new Set,v=new Set;let C=!1;const b=(0,c.a0)(this,(e=>this._instantiationService.createInstance((0,ne.b)(Ne,e),(0,s.zk)(this._domElement),this._editors,this._diffModel,this._options,this,(()=>C||f.get().isUpdatingHiddenAreas),_,v))).recomputeInitiallyAndOnChange(this._store),E=(0,l.un)(this,(e=>{const t=b.read(e).viewZones.read(e).orig,i=f.read(e).viewZones.read(e).origViewZones;return t.concat(i)})),y=(0,l.un)(this,(e=>{const t=b.read(e).viewZones.read(e).mod,i=f.read(e).viewZones.read(e).modViewZones;return t.concat(i)}));let w;this._register((0,S.Vs)(this._editors.original,E,(e=>{C=e}),_)),this._register((0,S.Vs)(this._editors.modified,y,(e=>{C=e,C?w=u.D.capture(this._editors.modified):(w?.restore(this._editors.modified),w=void 0)}),v)),this._accessibleDiffViewer=(0,c.a0)(this,(e=>this._instantiationService.createInstance((0,ne.b)(V,e),this.elements.accessibleDiffViewer,this._accessibleDiffViewerVisible,((e,t)=>this._accessibleDiffViewerShouldBeVisible.set(e,t)),this._options.onlyShowAccessibleDiffViewer.map((e=>!e)),this._rootSizeObserver.width,this._rootSizeObserver.height,this._diffModel.map(((e,t)=>e?.diff.read(t)?.mappings.map((e=>e.lineRangeMapping)))),new Z(this._editors)))).recomputeInitiallyAndOnChange(this._store);const L=this._accessibleDiffViewerVisible.map((e=>e?"hidden":"visible"));this._register((0,S.AV)(this.elements.modified,{visibility:L})),this._register((0,S.AV)(this.elements.original,{visibility:L})),this._createDiffEditorContributions(),d.addDiffEditor(this),this._gutter=(0,c.a0)(this,(e=>this._options.shouldRenderGutterMenu.read(e)?this._instantiationService.createInstance((0,ne.b)(it,e),this.elements.root,this._diffModel,this._editors,this._options,this._sashLayout,this._boundarySashes):void 0)),this._register((0,l.OI)(this._layoutInfo)),(0,c.a0)(this,(e=>new((0,ne.b)(Pe,e))(this.elements.root,this._diffModel,this._layoutInfo.map((e=>e.originalEditor)),this._layoutInfo.map((e=>e.modifiedEditor)),this._editors))).recomputeInitiallyAndOnChange(this._store,(e=>{this._movedBlocksLinesPart.set(e,void 0)})),this._register(o.Jh.runAndSubscribe(this._editors.modified.onDidChangeCursorPosition,(e=>this._handleCursorPositionChange(e,!0)))),this._register(o.Jh.runAndSubscribe(this._editors.original.onDidChangeCursorPosition,(e=>this._handleCursorPositionChange(e,!1))));const R=this._diffModel.map(this,((e,t)=>{if(e)return void 0===e.diff.read(t)&&!e.isDiffUpToDate.read(t)}));this._register((0,l.yC)(((e,t)=>{if(!0===R.read(e)){const e=this._editorProgressService.show(!0,1e3);t.add((0,a.s)((()=>e.done())))}}))),this._register((0,l.yC)(((e,t)=>{t.add(new((0,ne.b)(vt,e))(this._editors,this._diffModel,this._options,this))}))),this._register((0,l.yC)(((e,t)=>{const i=this._diffModel.read(e);if(i)for(const s of[i.model.original,i.model.modified])t.add(s.onWillDispose((e=>{(0,r.dz)(new r.D7("TextModel got disposed before DiffEditorWidget model got reset")),this.setModel(null)})))}))),this._register((0,l.fm)((e=>{this._options.setModel(this._diffModel.read(e))})))}_createInnerEditor(e,t,i,s){return e.createInstance(g.x,t,i,s)}_createDiffEditorContributions(){const e=h.dS.getDiffEditorContributions();for(const i of e)try{this._register(this._instantiationService.createInstance(i.ctor,this))}catch(t){(0,r.dz)(t)}}get _targetEditor(){return this._editors.modified}getEditorType(){return Et._.IDiffEditor}layout(e){this._rootSizeObserver.observe(e)}hasTextFocus(){return this._editors.original.hasTextFocus()||this._editors.modified.hasTextFocus()}saveViewState(){return{original:this._editors.original.saveViewState(),modified:this._editors.modified.saveViewState(),modelState:this._diffModel.get()?.serializeState()}}restoreViewState(e){if(e&&e.original&&e.modified){const t=e;this._editors.original.restoreViewState(t.original),this._editors.modified.restoreViewState(t.modified),t.modelState&&this._diffModel.get()?.restoreSerializedState(t.modelState)}}handleInitialized(){this._editors.original.handleInitialized(),this._editors.modified.handleInitialized()}createViewModel(e){return this._instantiationService.createInstance(ue,e,this._options)}getModel(){return this._diffModel.get()?.model??null}setModel(e){const t=e?"model"in e?S.O8.create(e).createNewRef(this):S.O8.create(this.createViewModel(e),this):null;this.setDiffModel(t)}setDiffModel(e,t){const i=this._diffModel.get();!e&&i&&this._accessibleDiffViewer.get().close(),this._diffModel.get()!==e?.object&&(0,l.PO)(t,(t=>{const i=e?.object;l.y0.batchEventsGlobally(t,(()=>{this._editors.original.setModel(i?i.model.original:null),this._editors.modified.setModel(i?i.model.modified:null)}));const s=this._diffModelSrc.get()?.createNewRef(this);this._diffModelSrc.set(e?.createNewRef(this),t),setTimeout((()=>{s?.dispose()}),0)}))}updateOptions(e){this._options.updateOptions(e)}getContainerDomNode(){return this._domElement}getOriginalEditor(){return this._editors.original}getModifiedEditor(){return this._editors.modified}getLineChanges(){const e=this._diffModel.get()?.diff.get();return e?e.mappings.map((e=>{const t=e.lineRangeMapping;let i,s,n,r,o=t.innerChanges;return t.original.isEmpty?(i=t.original.startLineNumber-1,s=0,o=void 0):(i=t.original.startLineNumber,s=t.original.endLineNumberExclusive-1),t.modified.isEmpty?(n=t.modified.startLineNumber-1,r=0,o=void 0):(n=t.modified.startLineNumber,r=t.modified.endLineNumberExclusive-1),{originalStartLineNumber:i,originalEndLineNumber:s,modifiedStartLineNumber:n,modifiedEndLineNumber:r,charChanges:o?.map((e=>({originalStartLineNumber:e.originalRange.startLineNumber,originalStartColumn:e.originalRange.startColumn,originalEndLineNumber:e.originalRange.endLineNumber,originalEndColumn:e.originalRange.endColumn,modifiedStartLineNumber:e.modifiedRange.startLineNumber,modifiedStartColumn:e.modifiedRange.startColumn,modifiedEndLineNumber:e.modifiedRange.endLineNumber,modifiedEndColumn:e.modifiedRange.endColumn})))}})):null}revert(e){const t=this._diffModel.get();t&&t.isDiffUpToDate.get()&&this._editors.modified.executeEdits("diffEditor",[{range:e.modified.toExclusiveRange(),text:t.model.original.getValueInRange(e.original.toExclusiveRange())}])}revertRangeMappings(e){const t=this._diffModel.get();if(!t||!t.isDiffUpToDate.get())return;const i=e.map((e=>({range:e.modifiedRange,text:t.model.original.getValueInRange(e.originalRange)})));this._editors.modified.executeEdits("diffEditor",i)}_goTo(e){this._editors.modified.setPosition(new R.y(e.lineRangeMapping.modified.startLineNumber,1)),this._editors.modified.revealRangeInCenter(e.lineRangeMapping.modified.toExclusiveRange())}goToDiff(e){const t=this._diffModel.get()?.diff.get()?.mappings;if(!t||0===t.length)return;const i=this._editors.modified.getPosition().lineNumber;let s;s="next"===e?t.find((e=>e.lineRangeMapping.modified.startLineNumber>i))??t[0]:(0,n.Uk)(t,(e=>e.lineRangeMapping.modified.startLineNumber{const t=e.diff.get()?.mappings;t&&0!==t.length&&this._goTo(t[0])}))}accessibleDiffViewerNext(){this._accessibleDiffViewer.get().next()}accessibleDiffViewerPrev(){this._accessibleDiffViewer.get().prev()}async waitForDiff(){const e=this._diffModel.get();e&&await e.waitForDiff()}mapToOtherSide(){const e=this._editors.modified.hasWidgetFocus(),t=e?this._editors.modified:this._editors.original,i=e?this._editors.original:this._editors.modified;let s;const n=t.getSelection();if(n){const t=this._diffModel.get()?.diff.get()?.mappings.map((t=>e?t.lineRangeMapping.flip():t.lineRangeMapping));if(t){const e=(0,S.Mu)(n.getStartPosition(),t),i=(0,S.Mu)(n.getEndPosition(),t);s=T.Q.plusRange(e,i)}}return{destination:i,destinationSelection:s}}switchSide(){const{destination:e,destinationSelection:t}=this.mapToOtherSide();e.focus(),t&&e.setSelection(t)}exitCompareMove(){const e=this._diffModel.get();e&&e.movedTextToCompare.set(void 0,void 0)}collapseAllUnchangedRegions(){const e=this._diffModel.get()?.unchangedRegions.get();e&&(0,l.Rn)((t=>{for(const i of e)i.collapseAll(t)}))}showAllUnchangedRegions(){const e=this._diffModel.get()?.unchangedRegions.get();e&&(0,l.Rn)((t=>{for(const i of e)i.showAll(t)}))}_handleCursorPositionChange(e,t){if(3===e?.reason){const i=this._diffModel.get()?.diff.get()?.mappings.find((i=>t?i.lineRangeMapping.modified.contains(e.position.lineNumber):i.lineRangeMapping.original.contains(e.position.lineNumber)));i?.lineRangeMapping.modified.isEmpty?this._accessibilitySignalService.playSignal(D.Rh.diffLineDeleted,{source:"diffEditor.cursorPositionChanged"}):i?.lineRangeMapping.original.isEmpty?this._accessibilitySignalService.playSignal(D.Rh.diffLineInserted,{source:"diffEditor.cursorPositionChanged"}):i&&this._accessibilitySignalService.playSignal(D.Rh.diffLineModified,{source:"diffEditor.cursorPositionChanged"})}}};Bt=Ut([Ht(3,Xe.fN),Ht(4,M._Y),Ht(5,d.T),Ht(6,D.Nt),Ht(7,wt.N8)],Bt)},94746:(e,t,i)=>{"use strict";i.d(t,{Hg:()=>p});var s,n=i(14718),r=i(63591),o=i(41234),a=i(78381),l=i(86571),c=i(87723),h=i(10920),d=i(90651),u=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};const p=(0,r.u1)("diffProviderFactoryService");let m=class{constructor(e){this.instantiationService=e}createDiffProvider(e){return this.instantiationService.createInstance(f,e)}};m=u([g(0,r._Y)],m),(0,n.v)(p,m,1);let f=class{static{s=this}static{this.diffCache=new Map}constructor(e,t,i){this.editorWorkerService=t,this.telemetryService=i,this.onDidChangeEventEmitter=new o.vl,this.onDidChange=this.onDidChangeEventEmitter.event,this.diffAlgorithm="advanced",this.diffAlgorithmOnDidChangeSubscription=void 0,this.setOptions(e)}dispose(){this.diffAlgorithmOnDidChangeSubscription?.dispose()}async computeDiff(e,t,i,n){if("string"!==typeof this.diffAlgorithm)return this.diffAlgorithm.computeDiff(e,t,i,n);if(e.isDisposed()||t.isDisposed())return{changes:[],identical:!0,quitEarly:!1,moves:[]};if(1===e.getLineCount()&&1===e.getLineMaxColumn(1))return 1===t.getLineCount()&&1===t.getLineMaxColumn(1)?{changes:[],identical:!0,quitEarly:!1,moves:[]}:{changes:[new c.wm(new l.M(1,2),new l.M(1,t.getLineCount()+1),[new c.q6(e.getFullModelRange(),t.getFullModelRange())])],identical:!1,quitEarly:!1,moves:[]};const r=JSON.stringify([e.uri.toString(),t.uri.toString()]),o=JSON.stringify([e.id,t.id,e.getAlternativeVersionId(),t.getAlternativeVersionId(),JSON.stringify(i)]),h=s.diffCache.get(r);if(h&&h.context===o)return h.result;const d=a.W.create(),u=await this.editorWorkerService.computeDiff(e.uri,t.uri,i,this.diffAlgorithm),g=d.elapsed();if(this.telemetryService.publicLog2("diffEditor.computeDiff",{timeMs:g,timedOut:u?.quitEarly??!0,detectedMoves:i.computeMoves?u?.moves.length??0:-1}),n.isCancellationRequested)return{changes:[],identical:!1,quitEarly:!0,moves:[]};if(!u)throw new Error("no diff result available");return s.diffCache.size>10&&s.diffCache.delete(s.diffCache.keys().next().value),s.diffCache.set(r,{result:u,context:o}),u}setOptions(e){let t=!1;e.diffAlgorithm&&this.diffAlgorithm!==e.diffAlgorithm&&(this.diffAlgorithmOnDidChangeSubscription?.dispose(),this.diffAlgorithmOnDidChangeSubscription=void 0,this.diffAlgorithm=e.diffAlgorithm,"string"!==typeof e.diffAlgorithm&&(this.diffAlgorithmOnDidChangeSubscription=e.diffAlgorithm.onDidChange((()=>this.onDidChangeEventEmitter.fire()))),t=!0),t&&this.onDidChangeEventEmitter.fire()}};f=s=u([g(1,h.IEditorWorkerService),g(2,d.k)],f)},34309:(e,t,i)=>{"use strict";i.d(t,{N:()=>y});var s,n=i(8597),r=i(20370),o=i(10350),a=i(16980),l=i(5662),c=i(31308),h=i(87958),d=i(25689),u=i(631),g=i(38844),p=i(92368),m=i(86571),f=i(83069),_=i(36677),v=i(62083),C=i(78209),b=i(63591),E=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},S=function(e,t){return function(i,s){t(i,s,e)}};let y=class extends l.jG{static{s=this}static{this._breadcrumbsSourceFactory=(0,c.FY)(s,(()=>({dispose(){},getBreadcrumbItems:(e,t)=>[]})))}static setBreadcrumbsSourceFactory(e){this._breadcrumbsSourceFactory.set(e,void 0)}get isUpdatingHiddenAreas(){return this._isUpdatingHiddenAreas}constructor(e,t,i,n){super(),this._editors=e,this._diffModel=t,this._options=i,this._instantiationService=n,this._modifiedOutlineSource=(0,h.a0)(this,(e=>{const t=this._editors.modifiedModel.read(e),i=s._breadcrumbsSourceFactory.read(e);return t&&i?i(t,this._instantiationService):void 0})),this._isUpdatingHiddenAreas=!1,this._register(this._editors.original.onDidChangeCursorPosition((e=>{if(1===e.reason)return;const t=this._diffModel.get();(0,c.Rn)((e=>{for(const i of this._editors.original.getSelections()||[])t?.ensureOriginalLineIsVisible(i.getStartPosition().lineNumber,0,e),t?.ensureOriginalLineIsVisible(i.getEndPosition().lineNumber,0,e)}))}))),this._register(this._editors.modified.onDidChangeCursorPosition((e=>{if(1===e.reason)return;const t=this._diffModel.get();(0,c.Rn)((e=>{for(const i of this._editors.modified.getSelections()||[])t?.ensureModifiedLineIsVisible(i.getStartPosition().lineNumber,0,e),t?.ensureModifiedLineIsVisible(i.getEndPosition().lineNumber,0,e)}))})));const r=this._diffModel.map(((e,t)=>{const i=e?.unchangedRegions.read(t)??[];return 1===i.length&&1===i[0].modifiedLineNumber&&i[0].lineCount===this._editors.modifiedModel.read(t)?.getLineCount()?[]:i}));this.viewZones=(0,c.rm)(this,((e,t)=>{const i=this._modifiedOutlineSource.read(e);if(!i)return{origViewZones:[],modViewZones:[]};const s=[],n=[],o=this._options.renderSideBySide.read(e),a=this._options.compactMode.read(e),l=r.read(e);for(let r=0;rh.getHiddenOriginalRange(e).startLineNumber-1)),i=new p.D1(e,12);s.push(i),t.add(new w(this._editors.original,i,h,!o))}{const e=(0,c.un)(this,(e=>h.getHiddenModifiedRange(e).startLineNumber-1)),i=new p.D1(e,12);n.push(i),t.add(new w(this._editors.modified,i,h))}}else{{const e=(0,c.un)(this,(e=>h.getHiddenOriginalRange(e).startLineNumber-1)),n=new p.D1(e,24);s.push(n),t.add(new L(this._editors.original,n,h,h.originalUnchangedRange,!o,i,(e=>this._diffModel.get().ensureModifiedLineIsVisible(e,2,void 0)),this._options))}{const e=(0,c.un)(this,(e=>h.getHiddenModifiedRange(e).startLineNumber-1)),s=new p.D1(e,24);n.push(s),t.add(new L(this._editors.modified,s,h,h.modifiedUnchangedRange,!1,i,(e=>this._diffModel.get().ensureModifiedLineIsVisible(e,2,void 0)),this._options))}}}return{origViewZones:s,modViewZones:n}}));const l={description:"unchanged lines",className:"diff-unchanged-lines",isWholeLine:!0},g={description:"Fold Unchanged",glyphMarginHoverMessage:new a.Bc(void 0,{isTrusted:!0,supportThemeIcons:!0}).appendMarkdown((0,C.kg)("foldUnchanged","Fold Unchanged Region")),glyphMarginClassName:"fold-unchanged "+d.L.asClassName(o.W.fold),zIndex:10001};this._register((0,p.pY)(this._editors.original,(0,c.un)(this,(e=>{const t=r.read(e),i=t.map((e=>({range:e.originalUnchangedRange.toInclusiveRange(),options:l})));for(const s of t)s.shouldHideControls(e)&&i.push({range:_.Q.fromPositions(new f.y(s.originalLineNumber,1)),options:g});return i})))),this._register((0,p.pY)(this._editors.modified,(0,c.un)(this,(e=>{const t=r.read(e),i=t.map((e=>({range:e.modifiedUnchangedRange.toInclusiveRange(),options:l})));for(const s of t)s.shouldHideControls(e)&&i.push({range:m.M.ofLength(s.modifiedLineNumber,1).toInclusiveRange(),options:g});return i})))),this._register((0,c.fm)((e=>{const t=r.read(e);this._isUpdatingHiddenAreas=!0;try{this._editors.original.setHiddenAreas(t.map((t=>t.getHiddenOriginalRange(e).toInclusiveRange())).filter(u.O9)),this._editors.modified.setHiddenAreas(t.map((t=>t.getHiddenModifiedRange(e).toInclusiveRange())).filter(u.O9))}finally{this._isUpdatingHiddenAreas=!1}}))),this._register(this._editors.modified.onMouseUp((e=>{if(!e.event.rightButton&&e.target.position&&e.target.element?.className.includes("fold-unchanged")){const t=e.target.position.lineNumber,i=this._diffModel.get();if(!i)return;const s=i.unchangedRegions.get().find((e=>e.modifiedUnchangedRange.includes(t)));if(!s)return;s.collapseAll(void 0),e.event.stopPropagation(),e.event.preventDefault()}}))),this._register(this._editors.original.onMouseUp((e=>{if(!e.event.rightButton&&e.target.position&&e.target.element?.className.includes("fold-unchanged")){const t=e.target.position.lineNumber,i=this._diffModel.get();if(!i)return;const s=i.unchangedRegions.get().find((e=>e.originalUnchangedRange.includes(t)));if(!s)return;s.collapseAll(void 0),e.event.stopPropagation(),e.event.preventDefault()}})))}};y=s=E([S(3,b._Y)],y);class w extends p.uN{constructor(e,t,i,s=!1){const r=(0,n.h)("div.diff-hidden-lines-widget");super(e,t,r.root),this._unchangedRegion=i,this._hide=s,this._nodes=(0,n.h)("div.diff-hidden-lines-compact",[(0,n.h)("div.line-left",[]),(0,n.h)("div.text@text",[]),(0,n.h)("div.line-right",[])]),r.root.appendChild(this._nodes.root),this._hide&&this._nodes.root.replaceChildren(),this._register((0,c.fm)((e=>{if(!this._hide){const t=this._unchangedRegion.getHiddenModifiedRange(e).length,i=(0,C.kg)("hiddenLines","{0} hidden lines",t);this._nodes.text.innerText=i}})))}}class L extends p.uN{constructor(e,t,i,s,a,l,h,d){const u=(0,n.h)("div.diff-hidden-lines-widget");super(e,t,u.root),this._editor=e,this._unchangedRegion=i,this._unchangedRegionRange=s,this._hide=a,this._modifiedOutlineSource=l,this._revealModifiedHiddenLine=h,this._options=d,this._nodes=(0,n.h)("div.diff-hidden-lines",[(0,n.h)("div.top@top",{title:(0,C.kg)("diff.hiddenLines.top","Click or drag to show more above")}),(0,n.h)("div.center@content",{style:{display:"flex"}},[(0,n.h)("div@first",{style:{display:"flex",justifyContent:"center",alignItems:"center",flexShrink:"0"}},[(0,n.$)("a",{title:(0,C.kg)("showUnchangedRegion","Show Unchanged Region"),role:"button",onclick:()=>{this._unchangedRegion.showAll(void 0)}},...(0,r.n)("$(unfold)"))]),(0,n.h)("div@others",{style:{display:"flex",justifyContent:"center",alignItems:"center"}})]),(0,n.h)("div.bottom@bottom",{title:(0,C.kg)("diff.bottom","Click or drag to show more below"),role:"button"})]),u.root.appendChild(this._nodes.root),this._hide?(0,n.Ln)(this._nodes.first):this._register((0,p.AV)(this._nodes.first,{width:(0,g.Ud)(this._editor).layoutInfoContentLeft})),this._register((0,c.fm)((e=>{const t=this._unchangedRegion.visibleLineCountTop.read(e)+this._unchangedRegion.visibleLineCountBottom.read(e)===this._unchangedRegion.lineCount;this._nodes.bottom.classList.toggle("canMoveTop",!t),this._nodes.bottom.classList.toggle("canMoveBottom",this._unchangedRegion.visibleLineCountBottom.read(e)>0),this._nodes.top.classList.toggle("canMoveTop",this._unchangedRegion.visibleLineCountTop.read(e)>0),this._nodes.top.classList.toggle("canMoveBottom",!t);const i=this._unchangedRegion.isDragged.read(e),s=this._editor.getDomNode();s&&(s.classList.toggle("draggingUnchangedRegion",!!i),"top"===i?(s.classList.toggle("canMoveTop",this._unchangedRegion.visibleLineCountTop.read(e)>0),s.classList.toggle("canMoveBottom",!t)):"bottom"===i?(s.classList.toggle("canMoveTop",!t),s.classList.toggle("canMoveBottom",this._unchangedRegion.visibleLineCountBottom.read(e)>0)):(s.classList.toggle("canMoveTop",!1),s.classList.toggle("canMoveBottom",!1)))})));const m=this._editor;this._register((0,n.ko)(this._nodes.top,"mousedown",(e=>{if(0!==e.button)return;this._nodes.top.classList.toggle("dragging",!0),this._nodes.root.classList.toggle("dragging",!0),e.preventDefault();const t=e.clientY;let i=!1;const s=this._unchangedRegion.visibleLineCountTop.get();this._unchangedRegion.isDragged.set("top",void 0);const r=(0,n.zk)(this._nodes.top),o=(0,n.ko)(r,"mousemove",(e=>{const n=e.clientY-t;i=i||Math.abs(n)>2;const r=Math.round(n/m.getOption(67)),o=Math.max(0,Math.min(s+r,this._unchangedRegion.getMaxVisibleLineCountTop()));this._unchangedRegion.visibleLineCountTop.set(o,void 0)})),a=(0,n.ko)(r,"mouseup",(e=>{i||this._unchangedRegion.showMoreAbove(this._options.hideUnchangedRegionsRevealLineCount.get(),void 0),this._nodes.top.classList.toggle("dragging",!1),this._nodes.root.classList.toggle("dragging",!1),this._unchangedRegion.isDragged.set(void 0,void 0),o.dispose(),a.dispose()}))}))),this._register((0,n.ko)(this._nodes.bottom,"mousedown",(e=>{if(0!==e.button)return;this._nodes.bottom.classList.toggle("dragging",!0),this._nodes.root.classList.toggle("dragging",!0),e.preventDefault();const t=e.clientY;let i=!1;const s=this._unchangedRegion.visibleLineCountBottom.get();this._unchangedRegion.isDragged.set("bottom",void 0);const r=(0,n.zk)(this._nodes.bottom),o=(0,n.ko)(r,"mousemove",(e=>{const n=e.clientY-t;i=i||Math.abs(n)>2;const r=Math.round(n/m.getOption(67)),o=Math.max(0,Math.min(s-r,this._unchangedRegion.getMaxVisibleLineCountBottom())),a=this._unchangedRegionRange.endLineNumberExclusive>m.getModel().getLineCount()?m.getContentHeight():m.getTopForLineNumber(this._unchangedRegionRange.endLineNumberExclusive);this._unchangedRegion.visibleLineCountBottom.set(o,void 0);const l=this._unchangedRegionRange.endLineNumberExclusive>m.getModel().getLineCount()?m.getContentHeight():m.getTopForLineNumber(this._unchangedRegionRange.endLineNumberExclusive);m.setScrollTop(m.getScrollTop()+(l-a))})),a=(0,n.ko)(r,"mouseup",(e=>{if(this._unchangedRegion.isDragged.set(void 0,void 0),!i){const e=m.getTopForLineNumber(this._unchangedRegionRange.endLineNumberExclusive);this._unchangedRegion.showMoreBelow(this._options.hideUnchangedRegionsRevealLineCount.get(),void 0);const t=m.getTopForLineNumber(this._unchangedRegionRange.endLineNumberExclusive);m.setScrollTop(m.getScrollTop()+(t-e))}this._nodes.bottom.classList.toggle("dragging",!1),this._nodes.root.classList.toggle("dragging",!1),o.dispose(),a.dispose()}))}))),this._register((0,c.fm)((e=>{const t=[];if(!this._hide){const s=i.getHiddenModifiedRange(e).length,a=(0,C.kg)("hiddenLines","{0} hidden lines",s),l=(0,n.$)("span",{title:(0,C.kg)("diff.hiddenLines.expandAll","Double click to unfold")},a);l.addEventListener("dblclick",(e=>{0===e.button&&(e.preventDefault(),this._unchangedRegion.showAll(void 0))})),t.push(l);const c=this._unchangedRegion.getHiddenModifiedRange(e),h=this._modifiedOutlineSource.getBreadcrumbItems(c,e);if(h.length>0){t.push((0,n.$)("span",void 0,"\xa0\xa0|\xa0\xa0"));for(let e=0;e{this._revealModifiedHiddenLine(i.startLineNumber)}}}}(0,n.Ln)(this._nodes.others,...t)})))}}},10691:(e,t,i)=>{"use strict";i.d(t,{GM:()=>_,KL:()=>C,Kl:()=>d,Ob:()=>u,Ou:()=>f,XT:()=>p,Zb:()=>v,Zw:()=>g,bk:()=>m,dv:()=>h,wp:()=>b});var s=i(10350),n=i(25689),r=i(87289),o=i(78209),a=i(66261),l=i(61394);(0,a.x1A)("diffEditor.move.border","#8b8b8b9c",(0,o.kg)("diffEditor.move.border","The border color for text that got moved in the diff editor.")),(0,a.x1A)("diffEditor.moveActive.border","#FFA500",(0,o.kg)("diffEditor.moveActive.border","The active border color for text that got moved in the diff editor.")),(0,a.x1A)("diffEditor.unchangedRegionShadow",{dark:"#000000",light:"#737373BF",hcDark:"#000000",hcLight:"#737373BF"},(0,o.kg)("diffEditor.unchangedRegionShadow","The color of the shadow around unchanged region widgets."));const c=(0,l.pU)("diff-insert",s.W.add,(0,o.kg)("diffInsertIcon","Line decoration for inserts in the diff editor.")),h=(0,l.pU)("diff-remove",s.W.remove,(0,o.kg)("diffRemoveIcon","Line decoration for removals in the diff editor.")),d=r.kI.register({className:"line-insert",description:"line-insert",isWholeLine:!0,linesDecorationsClassName:"insert-sign "+n.L.asClassName(c),marginClassName:"gutter-insert"}),u=r.kI.register({className:"line-delete",description:"line-delete",isWholeLine:!0,linesDecorationsClassName:"delete-sign "+n.L.asClassName(h),marginClassName:"gutter-delete"}),g=r.kI.register({className:"line-insert",description:"line-insert",isWholeLine:!0,marginClassName:"gutter-insert"}),p=r.kI.register({className:"line-delete",description:"line-delete",isWholeLine:!0,marginClassName:"gutter-delete"}),m=r.kI.register({className:"char-insert",description:"char-insert",shouldFillLineOnLineBreak:!0}),f=r.kI.register({className:"char-insert",description:"char-insert",isWholeLine:!0}),_=r.kI.register({className:"char-insert diff-range-empty",description:"char-insert diff-range-empty"}),v=r.kI.register({className:"char-delete",description:"char-delete",shouldFillLineOnLineBreak:!0}),C=r.kI.register({className:"char-delete",description:"char-delete",isWholeLine:!0}),b=r.kI.register({className:"char-delete diff-range-empty",description:"char-delete diff-range-empty"})},92368:(e,t,i)=>{"use strict";i.d(t,{$y:()=>p,AV:()=>b,Am:()=>d,D1:()=>v,EK:()=>w,MZ:()=>S,Mu:()=>y,Nu:()=>f,O8:()=>L,Vs:()=>E,pN:()=>m,pY:()=>u,rX:()=>g,uN:()=>_});var s=i(46041),n=i(18447),r=i(5662),o=i(31308),a=i(4983),l=i(83069),c=i(36677),h=i(50973);function d(e,t,i,s){if(0===e.length)return t;if(0===t.length)return e;const n=[];let r=0,o=0;for(;rh?(n.push(l),o++):(n.push(s(a,l)),r++,o++)}for(;r`Apply decorations from ${t.debugName}`},(e=>{const i=t.read(e);s.set(i)}))),i.add({dispose:()=>{s.clear()}}),i}function g(e,t){return e.appendChild(t),(0,r.s)((()=>{t.remove()}))}function p(e,t){return e.prepend(t),(0,r.s)((()=>{t.remove()}))}class m extends r.jG{get width(){return this._width}get height(){return this._height}get automaticLayout(){return this._automaticLayout}constructor(e,t){super(),this._automaticLayout=!1,this.elementSizeObserver=this._register(new a.u(e,t)),this._width=(0,o.FY)(this,this.elementSizeObserver.getWidth()),this._height=(0,o.FY)(this,this.elementSizeObserver.getHeight()),this._register(this.elementSizeObserver.onDidChange((e=>(0,o.Rn)((e=>{this._width.set(this.elementSizeObserver.getWidth(),e),this._height.set(this.elementSizeObserver.getHeight(),e)})))))}observe(e){this.elementSizeObserver.observe(e)}setAutomaticLayout(e){this._automaticLayout=e,e?this.elementSizeObserver.startObserving():this.elementSizeObserver.stopObserving()}}function f(e,t,i){let s=t.get(),n=s,r=s;const a=(0,o.FY)("animatedValue",s);let l=-1;let c;function h(){const t=Date.now()-l;var i,o,d,u;r=Math.floor((o=n,d=s-n,(i=t)===(u=300)?o+d:d*(1-Math.pow(2,-10*i/u))+o)),t<300?c=e.requestAnimationFrame(h):r=s,a.set(r,void 0)}return i.add((0,o.Y)({createEmptyChangeSummary:()=>({animate:!1}),handleChange:(e,i)=>(e.didChange(t)&&(i.animate=i.animate||e.change),!0)},((i,o)=>{void 0!==c&&(e.cancelAnimationFrame(c),c=void 0),n=r,s=t.read(i),l=Date.now()-(o.animate?0:300),h()}))),a}class _ extends r.jG{constructor(e,t,i){super(),this._register(new C(e,i)),this._register(b(i,{height:t.actualHeight,top:t.actualTop}))}}class v{get afterLineNumber(){return this._afterLineNumber.get()}constructor(e,t){this._afterLineNumber=e,this.heightInPx=t,this.domNode=document.createElement("div"),this._actualTop=(0,o.FY)(this,void 0),this._actualHeight=(0,o.FY)(this,void 0),this.actualTop=this._actualTop,this.actualHeight=this._actualHeight,this.showInHiddenAreas=!0,this.onChange=this._afterLineNumber,this.onDomNodeTop=e=>{this._actualTop.set(e,void 0)},this.onComputedHeight=e=>{this._actualHeight.set(e,void 0)}}}class C{static{this._counter=0}constructor(e,t){this._editor=e,this._domElement=t,this._overlayWidgetId="managedOverlayWidget-"+C._counter++,this._overlayWidget={getId:()=>this._overlayWidgetId,getDomNode:()=>this._domElement,getPosition:()=>null},this._editor.addOverlayWidget(this._overlayWidget)}dispose(){this._editor.removeOverlayWidget(this._overlayWidget)}}function b(e,t){return(0,o.fm)((i=>{for(let[s,n]of Object.entries(t))n&&"object"===typeof n&&"read"in n&&(n=n.read(i)),"number"===typeof n&&(n=`${n}px`),s=s.replace(/[A-Z]/g,(e=>"-"+e.toLowerCase())),e.style[s]=n}))}function E(e,t,i,s){const n=new r.Cm,a=[];return n.add((0,o.yC)(((n,r)=>{const l=t.read(n),c=new Map,h=new Map;i&&i(!0),e.changeViewZones((e=>{for(const t of a)e.removeZone(t),s?.delete(t);a.length=0;for(const t of l){const i=e.addZone(t);t.setZoneId&&t.setZoneId(i),a.push(i),s?.add(i),c.set(t,i)}})),i&&i(!1),r.add((0,o.Y)({createEmptyChangeSummary:()=>({zoneIds:[]}),handleChange(e,t){const i=h.get(e.changedObservable);return void 0!==i&&t.zoneIds.push(i),!0}},((t,s)=>{for(const e of l)e.onChange&&(h.set(e.onChange,c.get(e)),e.onChange.read(t));i&&i(!0),e.changeViewZones((e=>{for(const t of s.zoneIds)e.layoutZone(t)})),i&&i(!1)})))}))),n.add({dispose(){i&&i(!0),e.changeViewZones((e=>{for(const t of a)e.removeZone(t)})),s?.clear(),i&&i(!1)}}),n}class S extends n.Qi{dispose(){super.dispose(!0)}}function y(e,t){const i=(0,s.Uk)(t,(t=>t.original.startLineNumber<=e.lineNumber));if(!i)return c.Q.fromPositions(e);if(i.original.endLineNumberExclusive<=e.lineNumber){const t=e.lineNumber-i.original.endLineNumberExclusive+i.modified.endLineNumberExclusive;return c.Q.fromPositions(new l.y(t,e.column))}if(!i.innerChanges)return c.Q.fromPositions(new l.y(i.modified.startLineNumber,1));const n=(0,s.Uk)(i.innerChanges,(t=>t.originalRange.getStartPosition().isBeforeOrEqual(e)));if(!n){const t=e.lineNumber-i.original.startLineNumber+i.modified.startLineNumber;return c.Q.fromPositions(new l.y(t,e.column))}if(n.originalRange.containsPosition(e))return n.modifiedRange;{const t=(r=n.originalRange.getEndPosition(),o=e,r.lineNumber===o.lineNumber?new h.W(0,o.column-r.column):new h.W(o.lineNumber-r.lineNumber,o.column-1));return c.Q.fromPositions(t.addToPosition(n.modifiedRange.getEndPosition()))}var r,o}function w(e,t){let i;return e.filter((e=>{const s=t(e,i);return i=e,s}))}class L{static create(e,t=void 0){return new R(e,e,t)}static createWithDisposable(e,t,i=void 0){const s=new r.Cm;return s.add(t),s.add(e),new R(e,s,i)}}class R extends L{constructor(e,t,i){super(),this.object=e,this._disposable=t,this._debugOwner=i,this._refCount=1,this._isDisposed=!1,this._owners=[],i&&this._addOwner(i)}_addOwner(e){e&&this._owners.push(e)}createNewRef(e){return this._refCount++,e&&this._addOwner(e),new T(this,e)}dispose(){this._isDisposed||(this._isDisposed=!0,this._decreaseRefCount(this._debugOwner))}_decreaseRefCount(e){if(this._refCount--,0===this._refCount&&this._disposable.dispose(),e){const t=this._owners.indexOf(e);-1!==t&&this._owners.splice(t,1)}}}class T extends L{constructor(e,t){super(),this._base=e,this._debugOwner=t,this._isDisposed=!1}get object(){return this._base.object}createNewRef(e){return this._base.createNewRef(e)}dispose(){this._isDisposed||(this._isDisposed=!0,this._base._decreaseRefCount(this._debugOwner))}}},20492:(e,t,i)=>{"use strict";i.d(t,{T:()=>f,i:()=>_});var s,n=i(68214),r=i(80789),o=i(64383),a=i(41234),l=i(5662),c=i(73157),h=i(10154),d=i(83941),u=i(58314),g=i(49099),p=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},m=function(e,t){return function(i,s){t(i,s,e)}};let f=class{static{s=this}static{this._ttpTokenizer=(0,r.H)("tokenizeToString",{createHTML:e=>e})}constructor(e,t,i){this._options=e,this._languageService=t,this._openerService=i,this._onDidRenderAsync=new a.vl,this.onDidRenderAsync=this._onDidRenderAsync.event}dispose(){this._onDidRenderAsync.dispose()}render(e,t,i){if(!e){return{element:document.createElement("span"),dispose:()=>{}}}const s=new l.Cm,r=s.add((0,n.Gc)(e,{...this._getRenderOptions(e,s),...t},i));return r.element.classList.add("rendered-markdown"),{element:r.element,dispose:()=>s.dispose()}}_getRenderOptions(e,t){return{codeBlockRenderer:async(e,t)=>{let i;e?i=this._languageService.getLanguageIdByLanguageName(e):this._options.editor&&(i=this._options.editor.getModel()?.getLanguageId()),i||(i=d.vH);const n=await(0,u.Yj)(this._languageService,t,i),r=document.createElement("span");if(r.innerHTML=s._ttpTokenizer?.createHTML(n)??n,this._options.editor){const e=this._options.editor.getOption(50);(0,c.M)(r,e)}else this._options.codeBlockFontFamily&&(r.style.fontFamily=this._options.codeBlockFontFamily);return void 0!==this._options.codeBlockFontSize&&(r.style.fontSize=this._options.codeBlockFontSize),r},asyncRenderCallback:()=>this._onDidRenderAsync.fire(),actionHandler:{callback:t=>_(this._openerService,t,e.isTrusted),disposables:t}}}};async function _(e,t,i){try{return await e.open(t,{fromUserGesture:!0,allowContributedOpeners:!0,allowCommands:v(i)})}catch(s){return(0,o.dz)(s),!1}}function v(e){return!0===e||!(!e||!Array.isArray(e.enabledCommands))&&e.enabledCommands}f=s=p([m(1,h.L),m(2,g.C)],f)},25791:(e,t,i)=>{"use strict";i.d(t,{I:()=>n});var s=i(36921);class n extends s.LN{constructor(e){super(),this._getContext=e}runAction(e,t){const i=this._getContext();return super.runAction(e,i)}}},15092:(e,t,i)=>{"use strict";i.d(t,{iP:()=>a,iu:()=>n,q2:()=>o,tA:()=>r,ui:()=>l});var s=i(75326);class n{constructor(e,t,i=!1){this._range=e,this._text=t,this.insertsAutoWhitespace=i}getEditOperations(e,t){t.addTrackedEditOperation(this._range,this._text)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return s.L.fromPositions(i.getEndPosition())}}class r{constructor(e,t){this._range=e,this._text=t}getEditOperations(e,t){t.addTrackedEditOperation(this._range,this._text)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return s.L.fromRange(i,0)}}class o{constructor(e,t,i=!1){this._range=e,this._text=t,this.insertsAutoWhitespace=i}getEditOperations(e,t){t.addTrackedEditOperation(this._range,this._text)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return s.L.fromPositions(i.getStartPosition())}}class a{constructor(e,t,i,s,n=!1){this._range=e,this._text=t,this._columnDeltaOffset=s,this._lineNumberDeltaOffset=i,this.insertsAutoWhitespace=n}getEditOperations(e,t){t.addTrackedEditOperation(this._range,this._text)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return s.L.fromPositions(i.getEndPosition().delta(this._lineNumberDeltaOffset,this._columnDeltaOffset))}}class l{constructor(e,t,i,s=!1){this._range=e,this._text=t,this._initialSelection=i,this._forceMoveMarkers=s,this._selectionId=null}getEditOperations(e,t){t.addTrackedEditOperation(this._range,this._text,this._forceMoveMarkers),this._selectionId=t.trackSelection(this._initialSelection)}computeCursorState(e,t){return t.getTrackedSelection(this._selectionId)}}},7936:(e,t,i)=>{"use strict";i.d(t,{Y:()=>p});var s,n=i(91508),r=i(1245),o=i(36677),a=i(75326),l=i(63346),c=i(17469),h=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},d=function(e,t){return function(i,s){t(i,s,e)}};const u=Object.create(null);function g(e,t){if(t<=0)return"";u[e]||(u[e]=["",e]);const i=u[e];for(let s=i.length;s<=t;s++)i[s]=i[s-1]+e;return i[t]}let p=s=class{static unshiftIndent(e,t,i,s,n){const o=r.A.visibleColumnFromColumn(e,t,i);if(n){const e=g(" ",s);return g(e,r.A.prevIndentTabStop(o,s)/s)}return g("\t",r.A.prevRenderTabStop(o,i)/i)}static shiftIndent(e,t,i,s,n){const o=r.A.visibleColumnFromColumn(e,t,i);if(n){const e=g(" ",s);return g(e,r.A.nextIndentTabStop(o,s)/s)}return g("\t",r.A.nextRenderTabStop(o,i)/i)}constructor(e,t,i){this._languageConfigurationService=i,this._opts=t,this._selection=e,this._selectionId=null,this._useLastEditRangeForCursorEndPosition=!1,this._selectionStartColumnStaysPut=!1}_addEditOperation(e,t,i){this._useLastEditRangeForCursorEndPosition?e.addTrackedEditOperation(t,i):e.addEditOperation(t,i)}getEditOperations(e,t){const i=this._selection.startLineNumber;let a=this._selection.endLineNumber;1===this._selection.endColumn&&i!==a&&(a-=1);const{tabSize:c,indentSize:h,insertSpaces:d}=this._opts,u=i===a;if(this._opts.useTabStops){this._selection.isEmpty()&&/^\s*$/.test(e.getLineContent(i))&&(this._useLastEditRangeForCursorEndPosition=!0);let g=0,p=0;for(let m=i;m<=a;m++,g=p){p=0;const a=e.getLineContent(m);let f,_=n.HG(a);if((!this._opts.isUnshift||0!==a.length&&0!==_)&&(u||this._opts.isUnshift||0!==a.length)){if(-1===_&&(_=a.length),m>1){if(r.A.visibleColumnFromColumn(a,_+1,c)%h!==0&&e.tokenization.isCheapToTokenize(m-1)){const t=(0,l.h)(this._opts.autoIndent,e,new o.Q(m-1,e.getLineMaxColumn(m-1),m-1,e.getLineMaxColumn(m-1)),this._languageConfigurationService);if(t){if(p=g,t.appendText)for(let e=0,i=t.appendText.length;e{"use strict";i.d(t,{i:()=>r,y:()=>o});var s=i(36677),n=i(75326);class r{constructor(e,t,i){this._range=e,this._charBeforeSelection=t,this._charAfterSelection=i}getEditOperations(e,t){t.addTrackedEditOperation(new s.Q(this._range.startLineNumber,this._range.startColumn,this._range.startLineNumber,this._range.startColumn),this._charBeforeSelection),t.addTrackedEditOperation(new s.Q(this._range.endLineNumber,this._range.endColumn,this._range.endLineNumber,this._range.endColumn),this._charAfterSelection)}computeCursorState(e,t){const i=t.getInverseEditOperations(),s=i[0].range,r=i[1].range;return new n.L(s.endLineNumber,s.endColumn,r.endLineNumber,r.endColumn-this._charAfterSelection.length)}}class o{constructor(e,t,i){this._position=e,this._text=t,this._charAfter=i}getEditOperations(e,t){t.addTrackedEditOperation(new s.Q(this._position.lineNumber,this._position.column,this._position.lineNumber,this._position.column),this._text+this._charAfter)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return new n.L(i.endLineNumber,i.startColumn,i.endLineNumber,i.endColumn-this._charAfter.length)}}},61059:(e,t,i)=>{"use strict";i.d(t,{q:()=>s});const s={enableSplitViewResizing:!0,splitViewDefaultRatio:.5,renderSideBySide:!0,renderMarginRevertIcon:!0,renderGutterMenu:!0,maxComputationTime:5e3,maxFileSize:50,ignoreTrimWhitespace:!0,renderIndicators:!0,originalEditable:!1,diffCodeLens:!1,renderOverviewRuler:!0,diffWordWrap:"inherit",diffAlgorithm:"advanced",accessibilityVerbose:!1,experimental:{showMoves:!1,showEmptyDecorations:!0,useTrueInlineView:!1},hideUnchangedRegions:{enabled:!1,contextLineCount:3,minimumLineCount:3,revealLineCount:20},isInEmbeddedEditor:!1,onlyShowAccessibleDiffViewer:!1,renderSideBySideInlineBreakpoint:900,useInlineViewWhenSpaceIsLimited:!0,compactMode:!1}},94371:(e,t,i)=>{"use strict";i.d(t,{Gn:()=>m,JJ:()=>c,vf:()=>p});var s=i(61059),n=i(87908),r=i(24329),o=i(78209),a=i(1646),l=i(46359);const c=Object.freeze({id:"editor",order:5,type:"object",title:o.kg("editorConfigurationTitle","Editor"),scope:5}),h={...c,properties:{"editor.tabSize":{type:"number",default:r.R.tabSize,minimum:1,markdownDescription:o.kg("tabSize","The number of spaces a tab is equal to. This setting is overridden based on the file contents when {0} is on.","`#editor.detectIndentation#`")},"editor.indentSize":{anyOf:[{type:"string",enum:["tabSize"]},{type:"number",minimum:1}],default:"tabSize",markdownDescription:o.kg("indentSize",'The number of spaces used for indentation or `"tabSize"` to use the value from `#editor.tabSize#`. This setting is overridden based on the file contents when `#editor.detectIndentation#` is on.')},"editor.insertSpaces":{type:"boolean",default:r.R.insertSpaces,markdownDescription:o.kg("insertSpaces","Insert spaces when pressing `Tab`. This setting is overridden based on the file contents when {0} is on.","`#editor.detectIndentation#`")},"editor.detectIndentation":{type:"boolean",default:r.R.detectIndentation,markdownDescription:o.kg("detectIndentation","Controls whether {0} and {1} will be automatically detected when a file is opened based on the file contents.","`#editor.tabSize#`","`#editor.insertSpaces#`")},"editor.trimAutoWhitespace":{type:"boolean",default:r.R.trimAutoWhitespace,description:o.kg("trimAutoWhitespace","Remove trailing auto inserted whitespace.")},"editor.largeFileOptimizations":{type:"boolean",default:r.R.largeFileOptimizations,description:o.kg("largeFileOptimizations","Special handling for large files to disable certain memory intensive features.")},"editor.wordBasedSuggestions":{enum:["off","currentDocument","matchingDocuments","allDocuments"],default:"matchingDocuments",enumDescriptions:[o.kg("wordBasedSuggestions.off","Turn off Word Based Suggestions."),o.kg("wordBasedSuggestions.currentDocument","Only suggest words from the active document."),o.kg("wordBasedSuggestions.matchingDocuments","Suggest words from all open documents of the same language."),o.kg("wordBasedSuggestions.allDocuments","Suggest words from all open documents.")],description:o.kg("wordBasedSuggestions","Controls whether completions should be computed based on words in the document and from which documents they are computed.")},"editor.semanticHighlighting.enabled":{enum:[!0,!1,"configuredByTheme"],enumDescriptions:[o.kg("semanticHighlighting.true","Semantic highlighting enabled for all color themes."),o.kg("semanticHighlighting.false","Semantic highlighting disabled for all color themes."),o.kg("semanticHighlighting.configuredByTheme","Semantic highlighting is configured by the current color theme's `semanticHighlighting` setting.")],default:"configuredByTheme",description:o.kg("semanticHighlighting.enabled","Controls whether the semanticHighlighting is shown for the languages that support it.")},"editor.stablePeek":{type:"boolean",default:!1,markdownDescription:o.kg("stablePeek","Keep peek editors open even when double-clicking their content or when hitting `Escape`.")},"editor.maxTokenizationLineLength":{type:"integer",default:2e4,description:o.kg("maxTokenizationLineLength","Lines above this length will not be tokenized for performance reasons")},"editor.experimental.asyncTokenization":{type:"boolean",default:!0,description:o.kg("editor.experimental.asyncTokenization","Controls whether the tokenization should happen asynchronously on a web worker."),tags:["experimental"]},"editor.experimental.asyncTokenizationLogging":{type:"boolean",default:!1,description:o.kg("editor.experimental.asyncTokenizationLogging","Controls whether async tokenization should be logged. For debugging only.")},"editor.experimental.asyncTokenizationVerification":{type:"boolean",default:!1,description:o.kg("editor.experimental.asyncTokenizationVerification","Controls whether async tokenization should be verified against legacy background tokenization. Might slow down tokenization. For debugging only."),tags:["experimental"]},"editor.experimental.treeSitterTelemetry":{type:"boolean",default:!1,markdownDescription:o.kg("editor.experimental.treeSitterTelemetry","Controls whether tree sitter parsing should be turned on and telemetry collected. Setting `editor.experimental.preferTreeSitter` for specific languages will take precedence."),tags:["experimental"]},"editor.language.brackets":{type:["array","null"],default:null,description:o.kg("schema.brackets","Defines the bracket symbols that increase or decrease the indentation."),items:{type:"array",items:[{type:"string",description:o.kg("schema.openBracket","The opening bracket character or string sequence.")},{type:"string",description:o.kg("schema.closeBracket","The closing bracket character or string sequence.")}]}},"editor.language.colorizedBracketPairs":{type:["array","null"],default:null,description:o.kg("schema.colorizedBracketPairs","Defines the bracket pairs that are colorized by their nesting level if bracket pair colorization is enabled."),items:{type:"array",items:[{type:"string",description:o.kg("schema.openBracket","The opening bracket character or string sequence.")},{type:"string",description:o.kg("schema.closeBracket","The closing bracket character or string sequence.")}]}},"diffEditor.maxComputationTime":{type:"number",default:s.q.maxComputationTime,description:o.kg("maxComputationTime","Timeout in milliseconds after which diff computation is cancelled. Use 0 for no timeout.")},"diffEditor.maxFileSize":{type:"number",default:s.q.maxFileSize,description:o.kg("maxFileSize","Maximum file size in MB for which to compute diffs. Use 0 for no limit.")},"diffEditor.renderSideBySide":{type:"boolean",default:s.q.renderSideBySide,description:o.kg("sideBySide","Controls whether the diff editor shows the diff side by side or inline.")},"diffEditor.renderSideBySideInlineBreakpoint":{type:"number",default:s.q.renderSideBySideInlineBreakpoint,description:o.kg("renderSideBySideInlineBreakpoint","If the diff editor width is smaller than this value, the inline view is used.")},"diffEditor.useInlineViewWhenSpaceIsLimited":{type:"boolean",default:s.q.useInlineViewWhenSpaceIsLimited,description:o.kg("useInlineViewWhenSpaceIsLimited","If enabled and the editor width is too small, the inline view is used.")},"diffEditor.renderMarginRevertIcon":{type:"boolean",default:s.q.renderMarginRevertIcon,description:o.kg("renderMarginRevertIcon","When enabled, the diff editor shows arrows in its glyph margin to revert changes.")},"diffEditor.renderGutterMenu":{type:"boolean",default:s.q.renderGutterMenu,description:o.kg("renderGutterMenu","When enabled, the diff editor shows a special gutter for revert and stage actions.")},"diffEditor.ignoreTrimWhitespace":{type:"boolean",default:s.q.ignoreTrimWhitespace,description:o.kg("ignoreTrimWhitespace","When enabled, the diff editor ignores changes in leading or trailing whitespace.")},"diffEditor.renderIndicators":{type:"boolean",default:s.q.renderIndicators,description:o.kg("renderIndicators","Controls whether the diff editor shows +/- indicators for added/removed changes.")},"diffEditor.codeLens":{type:"boolean",default:s.q.diffCodeLens,description:o.kg("codeLens","Controls whether the editor shows CodeLens.")},"diffEditor.wordWrap":{type:"string",enum:["off","on","inherit"],default:s.q.diffWordWrap,markdownEnumDescriptions:[o.kg("wordWrap.off","Lines will never wrap."),o.kg("wordWrap.on","Lines will wrap at the viewport width."),o.kg("wordWrap.inherit","Lines will wrap according to the {0} setting.","`#editor.wordWrap#`")]},"diffEditor.diffAlgorithm":{type:"string",enum:["legacy","advanced"],default:s.q.diffAlgorithm,markdownEnumDescriptions:[o.kg("diffAlgorithm.legacy","Uses the legacy diffing algorithm."),o.kg("diffAlgorithm.advanced","Uses the advanced diffing algorithm.")],tags:["experimental"]},"diffEditor.hideUnchangedRegions.enabled":{type:"boolean",default:s.q.hideUnchangedRegions.enabled,markdownDescription:o.kg("hideUnchangedRegions.enabled","Controls whether the diff editor shows unchanged regions.")},"diffEditor.hideUnchangedRegions.revealLineCount":{type:"integer",default:s.q.hideUnchangedRegions.revealLineCount,markdownDescription:o.kg("hideUnchangedRegions.revealLineCount","Controls how many lines are used for unchanged regions."),minimum:1},"diffEditor.hideUnchangedRegions.minimumLineCount":{type:"integer",default:s.q.hideUnchangedRegions.minimumLineCount,markdownDescription:o.kg("hideUnchangedRegions.minimumLineCount","Controls how many lines are used as a minimum for unchanged regions."),minimum:1},"diffEditor.hideUnchangedRegions.contextLineCount":{type:"integer",default:s.q.hideUnchangedRegions.contextLineCount,markdownDescription:o.kg("hideUnchangedRegions.contextLineCount","Controls how many lines are used as context when comparing unchanged regions."),minimum:1},"diffEditor.experimental.showMoves":{type:"boolean",default:s.q.experimental.showMoves,markdownDescription:o.kg("showMoves","Controls whether the diff editor should show detected code moves.")},"diffEditor.experimental.showEmptyDecorations":{type:"boolean",default:s.q.experimental.showEmptyDecorations,description:o.kg("showEmptyDecorations","Controls whether the diff editor shows empty decorations to see where characters got inserted or deleted.")},"diffEditor.experimental.useTrueInlineView":{type:"boolean",default:s.q.experimental.useTrueInlineView,description:o.kg("useTrueInlineView","If enabled and the editor uses the inline view, word changes are rendered inline.")}}};for(const f of n.BE){const e=f.schema;if("undefined"!==typeof e)if("undefined"!==typeof(d=e).type||"undefined"!==typeof d.anyOf)h.properties[`editor.${f.name}`]=e;else for(const t in e)Object.hasOwnProperty.call(e,t)&&(h.properties[t]=e[t])}var d;let u=null;function g(){return null===u&&(u=Object.create(null),Object.keys(h.properties).forEach((e=>{u[e]=!0}))),u}function p(e){return g()[`editor.${e}`]||!1}function m(e){return g()[`diffEditor.${e}`]||!1}l.O.as(a.Fd.Configuration).registerConfiguration(h)},87908:(e,t,i)=>{"use strict";i.d(t,{$C:()=>O,BE:()=>H,Bc:()=>k,O4:()=>w,Of:()=>P,XR:()=>M,hZ:()=>g,jT:()=>x,jU:()=>U,ls:()=>E,lw:()=>h,m9:()=>T,n0:()=>d,qB:()=>W,r_:()=>A,wA:()=>C,xZ:()=>I,xq:()=>c,zM:()=>_});var s=i(25890),n=i(10146),r=i(98067),o=i(24329),a=i(26486),l=i(78209);const c=8;class h{constructor(e){this._values=e}hasChanged(e){return this._values[e]}}class d{constructor(){this.stableMinimapLayoutInput=null,this.stableFitMaxMinimapScale=0,this.stableFitRemainingWidth=0}}class u{constructor(e,t,i,s){this.id=e,this.name=t,this.defaultValue=i,this.schema=s}applyUpdate(e,t){return p(e,t)}compute(e,t,i){return i}}class g{constructor(e,t){this.newValue=e,this.didChange=t}}function p(e,t){if("object"!==typeof e||"object"!==typeof t||!e||!t)return new g(t,e!==t);if(Array.isArray(e)||Array.isArray(t)){const i=Array.isArray(e)&&Array.isArray(t)&&s.aI(e,t);return new g(t,!i)}let i=!1;for(const s in t)if(t.hasOwnProperty(s)){const n=p(e[s],t[s]);n.didChange&&(e[s]=n.newValue,i=!0)}return new g(e,i)}class m{constructor(e){this.schema=void 0,this.id=e,this.name="_never_",this.defaultValue=void 0}applyUpdate(e,t){return p(e,t)}validate(e){return this.defaultValue}}class f{constructor(e,t,i,s){this.id=e,this.name=t,this.defaultValue=i,this.schema=s}applyUpdate(e,t){return p(e,t)}validate(e){return"undefined"===typeof e?this.defaultValue:e}compute(e,t,i){return i}}function _(e,t){return"undefined"===typeof e?t:"false"!==e&&Boolean(e)}class v extends f{constructor(e,t,i,s=void 0){"undefined"!==typeof s&&(s.type="boolean",s.default=i),super(e,t,i,s)}validate(e){return _(e,this.defaultValue)}}function C(e,t,i,s){if("undefined"===typeof e)return t;let n=parseInt(e,10);return isNaN(n)?t:(n=Math.max(i,n),n=Math.min(s,n),0|n)}class b extends f{static clampedInt(e,t,i,s){return C(e,t,i,s)}constructor(e,t,i,s,n,r=void 0){"undefined"!==typeof r&&(r.type="integer",r.default=i,r.minimum=s,r.maximum=n),super(e,t,i,r),this.minimum=s,this.maximum=n}validate(e){return b.clampedInt(e,this.defaultValue,this.minimum,this.maximum)}}function E(e,t,i,s){if("undefined"===typeof e)return t;const n=S.float(e,t);return S.clamp(n,i,s)}class S extends f{static clamp(e,t,i){return ei?i:e}static float(e,t){if("number"===typeof e)return e;if("undefined"===typeof e)return t;const i=parseFloat(e);return isNaN(i)?t:i}constructor(e,t,i,s,n){"undefined"!==typeof n&&(n.type="number",n.default=i),super(e,t,i,n),this.validationFn=s}validate(e){return this.validationFn(S.float(e,this.defaultValue))}}class y extends f{static string(e,t){return"string"!==typeof e?t:e}constructor(e,t,i,s=void 0){"undefined"!==typeof s&&(s.type="string",s.default=i),super(e,t,i,s)}validate(e){return y.string(e,this.defaultValue)}}function w(e,t,i,s){return"string"!==typeof e?t:s&&e in s?s[e]:-1===i.indexOf(e)?t:e}class L extends f{constructor(e,t,i,s,n=void 0){"undefined"!==typeof n&&(n.type="string",n.enum=s,n.default=i),super(e,t,i,n),this._allowedValues=s}validate(e){return w(e,this.defaultValue,this._allowedValues)}}class R extends u{constructor(e,t,i,s,n,r,o=void 0){"undefined"!==typeof o&&(o.type="string",o.enum=n,o.default=s),super(e,t,i,o),this._allowedValues=n,this._convert=r}validate(e){return"string"!==typeof e||-1===this._allowedValues.indexOf(e)?this.defaultValue:this._convert(e)}}var T,x;!function(e){e[e.Line=1]="Line",e[e.Block=2]="Block",e[e.Underline=3]="Underline",e[e.LineThin=4]="LineThin",e[e.BlockOutline=5]="BlockOutline",e[e.UnderlineThin=6]="UnderlineThin"}(T||(T={}));class k extends u{static{this.OFF='"liga" off, "calt" off'}static{this.ON='"liga" on, "calt" on'}constructor(){super(51,"fontLigatures",k.OFF,{anyOf:[{type:"boolean",description:l.kg("fontLigatures","Enables/Disables font ligatures ('calt' and 'liga' font features). Change this to a string for fine-grained control of the 'font-feature-settings' CSS property.")},{type:"string",description:l.kg("fontFeatureSettings","Explicit 'font-feature-settings' CSS property. A boolean can be passed instead if one only needs to turn on/off ligatures.")}],description:l.kg("fontLigaturesGeneral","Configures font ligatures or font features. Can be either a boolean to enable/disable ligatures or a string for the value of the CSS 'font-feature-settings' property."),default:!1})}validate(e){return"undefined"===typeof e?this.defaultValue:"string"===typeof e?"false"===e||0===e.length?k.OFF:"true"===e?k.ON:e:Boolean(e)?k.ON:k.OFF}}class A extends u{static{this.OFF="normal"}static{this.TRANSLATE="translate"}constructor(){super(54,"fontVariations",A.OFF,{anyOf:[{type:"boolean",description:l.kg("fontVariations","Enables/Disables the translation from font-weight to font-variation-settings. Change this to a string for fine-grained control of the 'font-variation-settings' CSS property.")},{type:"string",description:l.kg("fontVariationSettings","Explicit 'font-variation-settings' CSS property. A boolean can be passed instead if one only needs to translate font-weight to font-variation-settings.")}],description:l.kg("fontVariationsGeneral","Configures font variations. Can be either a boolean to enable/disable the translation from font-weight to font-variation-settings or a string for the value of the CSS 'font-variation-settings' property."),default:!1})}validate(e){return"undefined"===typeof e?this.defaultValue:"string"===typeof e?"false"===e?A.OFF:"true"===e?A.TRANSLATE:e:Boolean(e)?A.TRANSLATE:A.OFF}compute(e,t,i){return e.fontInfo.fontVariationSettings}}class N extends u{static{this.SUGGESTION_VALUES=["normal","bold","100","200","300","400","500","600","700","800","900"]}static{this.MINIMUM_VALUE=1}static{this.MAXIMUM_VALUE=1e3}constructor(){super(53,"fontWeight",U.fontWeight,{anyOf:[{type:"number",minimum:N.MINIMUM_VALUE,maximum:N.MAXIMUM_VALUE,errorMessage:l.kg("fontWeightErrorMessage",'Only "normal" and "bold" keywords or numbers between 1 and 1000 are allowed.')},{type:"string",pattern:"^(normal|bold|1000|[1-9][0-9]{0,2})$"},{enum:N.SUGGESTION_VALUES}],default:U.fontWeight,description:l.kg("fontWeight",'Controls the font weight. Accepts "normal" and "bold" keywords or numbers between 1 and 1000.')})}validate(e){return"normal"===e||"bold"===e?e:String(b.clampedInt(e,U.fontWeight,N.MINIMUM_VALUE,N.MAXIMUM_VALUE))}}class I extends m{constructor(){super(146)}compute(e,t,i){return I.computeLayout(t,{memory:e.memory,outerWidth:e.outerWidth,outerHeight:e.outerHeight,isDominatedByLongLines:e.isDominatedByLongLines,lineHeight:e.fontInfo.lineHeight,viewLineCount:e.viewLineCount,lineNumbersDigitCount:e.lineNumbersDigitCount,typicalHalfwidthCharacterWidth:e.fontInfo.typicalHalfwidthCharacterWidth,maxDigitWidth:e.fontInfo.maxDigitWidth,pixelRatio:e.pixelRatio,glyphMarginDecorationLaneCount:e.glyphMarginDecorationLaneCount})}static computeContainedMinimapLineCount(e){const t=e.height/e.lineHeight,i=Math.floor(e.paddingTop/e.lineHeight);let s=Math.floor(e.paddingBottom/e.lineHeight);e.scrollBeyondLastLine&&(s=Math.max(s,t-1));const n=(i+e.viewLineCount+s)/(e.pixelRatio*e.height);return{typicalViewportLineCount:t,extraLinesBeforeFirstLine:i,extraLinesBeyondLastLine:s,desiredRatio:n,minimapLineCount:Math.floor(e.viewLineCount/n)}}static _computeMinimapLayout(e,t){const i=e.outerWidth,s=e.outerHeight,n=e.pixelRatio;if(!e.minimap.enabled)return{renderMinimap:0,minimapLeft:0,minimapWidth:0,minimapHeightIsEditorHeight:!1,minimapIsSampling:!1,minimapScale:1,minimapLineHeight:1,minimapCanvasInnerWidth:0,minimapCanvasInnerHeight:Math.floor(n*s),minimapCanvasOuterWidth:0,minimapCanvasOuterHeight:s};const r=t.stableMinimapLayoutInput,o=r&&e.outerHeight===r.outerHeight&&e.lineHeight===r.lineHeight&&e.typicalHalfwidthCharacterWidth===r.typicalHalfwidthCharacterWidth&&e.pixelRatio===r.pixelRatio&&e.scrollBeyondLastLine===r.scrollBeyondLastLine&&e.paddingTop===r.paddingTop&&e.paddingBottom===r.paddingBottom&&e.minimap.enabled===r.minimap.enabled&&e.minimap.side===r.minimap.side&&e.minimap.size===r.minimap.size&&e.minimap.showSlider===r.minimap.showSlider&&e.minimap.renderCharacters===r.minimap.renderCharacters&&e.minimap.maxColumn===r.minimap.maxColumn&&e.minimap.scale===r.minimap.scale&&e.verticalScrollbarWidth===r.verticalScrollbarWidth&&e.isViewportWrapping===r.isViewportWrapping,a=e.lineHeight,l=e.typicalHalfwidthCharacterWidth,h=e.scrollBeyondLastLine,d=e.minimap.renderCharacters;let u=n>=2?Math.round(2*e.minimap.scale):e.minimap.scale;const g=e.minimap.maxColumn,p=e.minimap.size,m=e.minimap.side,f=e.verticalScrollbarWidth,_=e.viewLineCount,v=e.remainingWidth,C=e.isViewportWrapping,b=d?2:3;let E=Math.floor(n*s);const S=E/n;let y=!1,w=!1,L=b*u,R=u/n,T=1;if("fill"===p||"fit"===p){const{typicalViewportLineCount:i,extraLinesBeforeFirstLine:r,extraLinesBeyondLastLine:l,desiredRatio:c,minimapLineCount:d}=I.computeContainedMinimapLineCount({viewLineCount:_,scrollBeyondLastLine:h,paddingTop:e.paddingTop,paddingBottom:e.paddingBottom,height:s,lineHeight:a,pixelRatio:n});if(_/d>1)y=!0,w=!0,u=1,L=1,R=u/n;else{let s=!1,h=u+1;if("fit"===p){const e=Math.ceil((r+_+l)*L);C&&o&&v<=t.stableFitRemainingWidth?(s=!0,h=t.stableFitMaxMinimapScale):s=e>E}if("fill"===p||s){y=!0;const s=u;L=Math.min(a*n,Math.max(1,Math.floor(1/c))),C&&o&&v<=t.stableFitRemainingWidth&&(h=t.stableFitMaxMinimapScale),u=Math.min(h,Math.max(1,Math.floor(L/b))),u>s&&(T=Math.min(2,u/s)),R=u/n/T,E=Math.ceil(Math.max(i,r+_+l)*L),C?(t.stableMinimapLayoutInput=e,t.stableFitRemainingWidth=v,t.stableFitMaxMinimapScale=u):(t.stableMinimapLayoutInput=null,t.stableFitRemainingWidth=0)}}}const x=Math.floor(g*R),k=Math.min(x,Math.max(0,Math.floor((v-f-2)*R/(l+R)))+c);let A=Math.floor(n*k);const N=A/n;A=Math.floor(A*T);return{renderMinimap:d?1:2,minimapLeft:"left"===m?0:i-k-f,minimapWidth:k,minimapHeightIsEditorHeight:y,minimapIsSampling:w,minimapScale:u,minimapLineHeight:L,minimapCanvasInnerWidth:A,minimapCanvasInnerHeight:E,minimapCanvasOuterWidth:N,minimapCanvasOuterHeight:S}}static computeLayout(e,t){const i=0|t.outerWidth,s=0|t.outerHeight,n=0|t.lineHeight,r=0|t.lineNumbersDigitCount,o=t.typicalHalfwidthCharacterWidth,a=t.maxDigitWidth,l=t.pixelRatio,c=t.viewLineCount,h=e.get(138),u="inherit"===h?e.get(137):h,g="inherit"===u?e.get(133):u,p=e.get(136),m=t.isDominatedByLongLines,f=e.get(57),_=0!==e.get(68).renderType,v=e.get(69),C=e.get(106),b=e.get(84),E=e.get(73),S=e.get(104),y=S.verticalScrollbarSize,w=S.verticalHasArrows,L=S.arrowSize,R=S.horizontalScrollbarSize,T=e.get(43),x="never"!==e.get(111);let k=e.get(66);T&&x&&(k+=16);let A=0;if(_){const e=Math.max(r,v);A=Math.round(e*a)}let N=0;f&&(N=n*t.glyphMarginDecorationLaneCount);let O=0,D=O+N,M=D+A,P=M+k;const F=i-N-A-k;let U=!1,H=!1,B=-1;"inherit"===u&&m?(U=!0,H=!0):"on"===g||"bounded"===g?H=!0:"wordWrapColumn"===g&&(B=p);const W=I._computeMinimapLayout({outerWidth:i,outerHeight:s,lineHeight:n,typicalHalfwidthCharacterWidth:o,pixelRatio:l,scrollBeyondLastLine:C,paddingTop:b.top,paddingBottom:b.bottom,minimap:E,verticalScrollbarWidth:y,viewLineCount:c,remainingWidth:F,isViewportWrapping:H},t.memory||new d);0!==W.renderMinimap&&0===W.minimapLeft&&(O+=W.minimapWidth,D+=W.minimapWidth,M+=W.minimapWidth,P+=W.minimapWidth);const V=F-W.minimapWidth,z=Math.max(1,Math.floor((V-y-2)/o)),G=w?L:0;return H&&(B=Math.max(1,z),"bounded"===g&&(B=Math.min(B,p))),{width:i,height:s,glyphMarginLeft:O,glyphMarginWidth:N,glyphMarginDecorationLaneCount:t.glyphMarginDecorationLaneCount,lineNumbersLeft:D,lineNumbersWidth:A,decorationsLeft:M,decorationsWidth:k,contentLeft:P,contentWidth:V,minimap:W,viewportColumn:z,isWordWrapMinified:U,isViewportWrapping:H,wrappingColumn:B,verticalScrollbarWidth:y,horizontalScrollbarHeight:R,overviewRuler:{top:G,width:y,height:s-2*G,right:0}}}}!function(e){e.Off="off",e.OnCode="onCode",e.On="on"}(x||(x={}));function O(e){const t=e.get(99);return"editable"===t?e.get(92):"on"!==t}function D(e,t){if("string"!==typeof e)return t;switch(e){case"hidden":return 2;case"visible":return 3;default:return 1}}const M="inUntrustedWorkspace",P={allowedCharacters:"editor.unicodeHighlight.allowedCharacters",invisibleCharacters:"editor.unicodeHighlight.invisibleCharacters",nonBasicASCII:"editor.unicodeHighlight.nonBasicASCII",ambiguousCharacters:"editor.unicodeHighlight.ambiguousCharacters",includeComments:"editor.unicodeHighlight.includeComments",includeStrings:"editor.unicodeHighlight.includeStrings",allowedLocales:"editor.unicodeHighlight.allowedLocales"};function F(e,t,i){const s=i.indexOf(e);return-1===s?t:i[s]}const U={fontFamily:r.zx?"Menlo, Monaco, 'Courier New', monospace":r.j9?"'Droid Sans Mono', 'monospace', monospace":"Consolas, 'Courier New', monospace",fontWeight:"normal",fontSize:r.zx?12:14,lineHeight:0,letterSpacing:0},H=[];function B(e){return H[e.id]=e,e}const W={acceptSuggestionOnCommitCharacter:B(new v(0,"acceptSuggestionOnCommitCharacter",!0,{markdownDescription:l.kg("acceptSuggestionOnCommitCharacter","Controls whether suggestions should be accepted on commit characters. For example, in JavaScript, the semi-colon (`;`) can be a commit character that accepts a suggestion and types that character.")})),acceptSuggestionOnEnter:B(new L(1,"acceptSuggestionOnEnter","on",["on","smart","off"],{markdownEnumDescriptions:["",l.kg("acceptSuggestionOnEnterSmart","Only accept a suggestion with `Enter` when it makes a textual change."),""],markdownDescription:l.kg("acceptSuggestionOnEnter","Controls whether suggestions should be accepted on `Enter`, in addition to `Tab`. Helps to avoid ambiguity between inserting new lines or accepting suggestions.")})),accessibilitySupport:B(new class extends u{constructor(){super(2,"accessibilitySupport",0,{type:"string",enum:["auto","on","off"],enumDescriptions:[l.kg("accessibilitySupport.auto","Use platform APIs to detect when a Screen Reader is attached."),l.kg("accessibilitySupport.on","Optimize for usage with a Screen Reader."),l.kg("accessibilitySupport.off","Assume a screen reader is not attached.")],default:"auto",tags:["accessibility"],description:l.kg("accessibilitySupport","Controls if the UI should run in a mode where it is optimized for screen readers.")})}validate(e){switch(e){case"auto":return 0;case"off":return 1;case"on":return 2}return this.defaultValue}compute(e,t,i){return 0===i?e.accessibilitySupport:i}}),accessibilityPageSize:B(new b(3,"accessibilityPageSize",10,1,1073741824,{description:l.kg("accessibilityPageSize","Controls the number of lines in the editor that can be read out by a screen reader at once. When we detect a screen reader we automatically set the default to be 500. Warning: this has a performance implication for numbers larger than the default."),tags:["accessibility"]})),ariaLabel:B(new y(4,"ariaLabel",l.kg("editorViewAccessibleLabel","Editor content"))),ariaRequired:B(new v(5,"ariaRequired",!1,void 0)),screenReaderAnnounceInlineSuggestion:B(new v(8,"screenReaderAnnounceInlineSuggestion",!0,{description:l.kg("screenReaderAnnounceInlineSuggestion","Control whether inline suggestions are announced by a screen reader."),tags:["accessibility"]})),autoClosingBrackets:B(new L(6,"autoClosingBrackets","languageDefined",["always","languageDefined","beforeWhitespace","never"],{enumDescriptions:["",l.kg("editor.autoClosingBrackets.languageDefined","Use language configurations to determine when to autoclose brackets."),l.kg("editor.autoClosingBrackets.beforeWhitespace","Autoclose brackets only when the cursor is to the left of whitespace."),""],description:l.kg("autoClosingBrackets","Controls whether the editor should automatically close brackets after the user adds an opening bracket.")})),autoClosingComments:B(new L(7,"autoClosingComments","languageDefined",["always","languageDefined","beforeWhitespace","never"],{enumDescriptions:["",l.kg("editor.autoClosingComments.languageDefined","Use language configurations to determine when to autoclose comments."),l.kg("editor.autoClosingComments.beforeWhitespace","Autoclose comments only when the cursor is to the left of whitespace."),""],description:l.kg("autoClosingComments","Controls whether the editor should automatically close comments after the user adds an opening comment.")})),autoClosingDelete:B(new L(9,"autoClosingDelete","auto",["always","auto","never"],{enumDescriptions:["",l.kg("editor.autoClosingDelete.auto","Remove adjacent closing quotes or brackets only if they were automatically inserted."),""],description:l.kg("autoClosingDelete","Controls whether the editor should remove adjacent closing quotes or brackets when deleting.")})),autoClosingOvertype:B(new L(10,"autoClosingOvertype","auto",["always","auto","never"],{enumDescriptions:["",l.kg("editor.autoClosingOvertype.auto","Type over closing quotes or brackets only if they were automatically inserted."),""],description:l.kg("autoClosingOvertype","Controls whether the editor should type over closing quotes or brackets.")})),autoClosingQuotes:B(new L(11,"autoClosingQuotes","languageDefined",["always","languageDefined","beforeWhitespace","never"],{enumDescriptions:["",l.kg("editor.autoClosingQuotes.languageDefined","Use language configurations to determine when to autoclose quotes."),l.kg("editor.autoClosingQuotes.beforeWhitespace","Autoclose quotes only when the cursor is to the left of whitespace."),""],description:l.kg("autoClosingQuotes","Controls whether the editor should automatically close quotes after the user adds an opening quote.")})),autoIndent:B(new R(12,"autoIndent",4,"full",["none","keep","brackets","advanced","full"],(function(e){switch(e){case"none":return 0;case"keep":return 1;case"brackets":return 2;case"advanced":return 3;case"full":return 4}}),{enumDescriptions:[l.kg("editor.autoIndent.none","The editor will not insert indentation automatically."),l.kg("editor.autoIndent.keep","The editor will keep the current line's indentation."),l.kg("editor.autoIndent.brackets","The editor will keep the current line's indentation and honor language defined brackets."),l.kg("editor.autoIndent.advanced","The editor will keep the current line's indentation, honor language defined brackets and invoke special onEnterRules defined by languages."),l.kg("editor.autoIndent.full","The editor will keep the current line's indentation, honor language defined brackets, invoke special onEnterRules defined by languages, and honor indentationRules defined by languages.")],description:l.kg("autoIndent","Controls whether the editor should automatically adjust the indentation when users type, paste, move or indent lines.")})),automaticLayout:B(new v(13,"automaticLayout",!1)),autoSurround:B(new L(14,"autoSurround","languageDefined",["languageDefined","quotes","brackets","never"],{enumDescriptions:[l.kg("editor.autoSurround.languageDefined","Use language configurations to determine when to automatically surround selections."),l.kg("editor.autoSurround.quotes","Surround with quotes but not brackets."),l.kg("editor.autoSurround.brackets","Surround with brackets but not quotes."),""],description:l.kg("autoSurround","Controls whether the editor should automatically surround selections when typing quotes or brackets.")})),bracketPairColorization:B(new class extends u{constructor(){const e={enabled:o.R.bracketPairColorizationOptions.enabled,independentColorPoolPerBracketType:o.R.bracketPairColorizationOptions.independentColorPoolPerBracketType};super(15,"bracketPairColorization",e,{"editor.bracketPairColorization.enabled":{type:"boolean",default:e.enabled,markdownDescription:l.kg("bracketPairColorization.enabled","Controls whether bracket pair colorization is enabled or not. Use {0} to override the bracket highlight colors.","`#workbench.colorCustomizations#`")},"editor.bracketPairColorization.independentColorPoolPerBracketType":{type:"boolean",default:e.independentColorPoolPerBracketType,description:l.kg("bracketPairColorization.independentColorPoolPerBracketType","Controls whether each bracket type has its own independent color pool.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),independentColorPoolPerBracketType:_(t.independentColorPoolPerBracketType,this.defaultValue.independentColorPoolPerBracketType)}}}),bracketPairGuides:B(new class extends u{constructor(){const e={bracketPairs:!1,bracketPairsHorizontal:"active",highlightActiveBracketPair:!0,indentation:!0,highlightActiveIndentation:!0};super(16,"guides",e,{"editor.guides.bracketPairs":{type:["boolean","string"],enum:[!0,"active",!1],enumDescriptions:[l.kg("editor.guides.bracketPairs.true","Enables bracket pair guides."),l.kg("editor.guides.bracketPairs.active","Enables bracket pair guides only for the active bracket pair."),l.kg("editor.guides.bracketPairs.false","Disables bracket pair guides.")],default:e.bracketPairs,description:l.kg("editor.guides.bracketPairs","Controls whether bracket pair guides are enabled or not.")},"editor.guides.bracketPairsHorizontal":{type:["boolean","string"],enum:[!0,"active",!1],enumDescriptions:[l.kg("editor.guides.bracketPairsHorizontal.true","Enables horizontal guides as addition to vertical bracket pair guides."),l.kg("editor.guides.bracketPairsHorizontal.active","Enables horizontal guides only for the active bracket pair."),l.kg("editor.guides.bracketPairsHorizontal.false","Disables horizontal bracket pair guides.")],default:e.bracketPairsHorizontal,description:l.kg("editor.guides.bracketPairsHorizontal","Controls whether horizontal bracket pair guides are enabled or not.")},"editor.guides.highlightActiveBracketPair":{type:"boolean",default:e.highlightActiveBracketPair,description:l.kg("editor.guides.highlightActiveBracketPair","Controls whether the editor should highlight the active bracket pair.")},"editor.guides.indentation":{type:"boolean",default:e.indentation,description:l.kg("editor.guides.indentation","Controls whether the editor should render indent guides.")},"editor.guides.highlightActiveIndentation":{type:["boolean","string"],enum:[!0,"always",!1],enumDescriptions:[l.kg("editor.guides.highlightActiveIndentation.true","Highlights the active indent guide."),l.kg("editor.guides.highlightActiveIndentation.always","Highlights the active indent guide even if bracket guides are highlighted."),l.kg("editor.guides.highlightActiveIndentation.false","Do not highlight the active indent guide.")],default:e.highlightActiveIndentation,description:l.kg("editor.guides.highlightActiveIndentation","Controls whether the editor should highlight the active indent guide.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{bracketPairs:F(t.bracketPairs,this.defaultValue.bracketPairs,[!0,!1,"active"]),bracketPairsHorizontal:F(t.bracketPairsHorizontal,this.defaultValue.bracketPairsHorizontal,[!0,!1,"active"]),highlightActiveBracketPair:_(t.highlightActiveBracketPair,this.defaultValue.highlightActiveBracketPair),indentation:_(t.indentation,this.defaultValue.indentation),highlightActiveIndentation:F(t.highlightActiveIndentation,this.defaultValue.highlightActiveIndentation,[!0,!1,"always"])}}}),stickyTabStops:B(new v(117,"stickyTabStops",!1,{description:l.kg("stickyTabStops","Emulate selection behavior of tab characters when using spaces for indentation. Selection will stick to tab stops.")})),codeLens:B(new v(17,"codeLens",!0,{description:l.kg("codeLens","Controls whether the editor shows CodeLens.")})),codeLensFontFamily:B(new y(18,"codeLensFontFamily","",{description:l.kg("codeLensFontFamily","Controls the font family for CodeLens.")})),codeLensFontSize:B(new b(19,"codeLensFontSize",0,0,100,{type:"number",default:0,minimum:0,maximum:100,markdownDescription:l.kg("codeLensFontSize","Controls the font size in pixels for CodeLens. When set to 0, 90% of `#editor.fontSize#` is used.")})),colorDecorators:B(new v(20,"colorDecorators",!0,{description:l.kg("colorDecorators","Controls whether the editor should render the inline color decorators and color picker.")})),colorDecoratorActivatedOn:B(new L(149,"colorDecoratorsActivatedOn","clickAndHover",["clickAndHover","hover","click"],{enumDescriptions:[l.kg("editor.colorDecoratorActivatedOn.clickAndHover","Make the color picker appear both on click and hover of the color decorator"),l.kg("editor.colorDecoratorActivatedOn.hover","Make the color picker appear on hover of the color decorator"),l.kg("editor.colorDecoratorActivatedOn.click","Make the color picker appear on click of the color decorator")],description:l.kg("colorDecoratorActivatedOn","Controls the condition to make a color picker appear from a color decorator")})),colorDecoratorsLimit:B(new b(21,"colorDecoratorsLimit",500,1,1e6,{markdownDescription:l.kg("colorDecoratorsLimit","Controls the max number of color decorators that can be rendered in an editor at once.")})),columnSelection:B(new v(22,"columnSelection",!1,{description:l.kg("columnSelection","Enable that the selection with the mouse and keys is doing column selection.")})),comments:B(new class extends u{constructor(){const e={insertSpace:!0,ignoreEmptyLines:!0};super(23,"comments",e,{"editor.comments.insertSpace":{type:"boolean",default:e.insertSpace,description:l.kg("comments.insertSpace","Controls whether a space character is inserted when commenting.")},"editor.comments.ignoreEmptyLines":{type:"boolean",default:e.ignoreEmptyLines,description:l.kg("comments.ignoreEmptyLines","Controls if empty lines should be ignored with toggle, add or remove actions for line comments.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{insertSpace:_(t.insertSpace,this.defaultValue.insertSpace),ignoreEmptyLines:_(t.ignoreEmptyLines,this.defaultValue.ignoreEmptyLines)}}}),contextmenu:B(new v(24,"contextmenu",!0)),copyWithSyntaxHighlighting:B(new v(25,"copyWithSyntaxHighlighting",!0,{description:l.kg("copyWithSyntaxHighlighting","Controls whether syntax highlighting should be copied into the clipboard.")})),cursorBlinking:B(new R(26,"cursorBlinking",1,"blink",["blink","smooth","phase","expand","solid"],(function(e){switch(e){case"blink":return 1;case"smooth":return 2;case"phase":return 3;case"expand":return 4;case"solid":return 5}}),{description:l.kg("cursorBlinking","Control the cursor animation style.")})),cursorSmoothCaretAnimation:B(new L(27,"cursorSmoothCaretAnimation","off",["off","explicit","on"],{enumDescriptions:[l.kg("cursorSmoothCaretAnimation.off","Smooth caret animation is disabled."),l.kg("cursorSmoothCaretAnimation.explicit","Smooth caret animation is enabled only when the user moves the cursor with an explicit gesture."),l.kg("cursorSmoothCaretAnimation.on","Smooth caret animation is always enabled.")],description:l.kg("cursorSmoothCaretAnimation","Controls whether the smooth caret animation should be enabled.")})),cursorStyle:B(new R(28,"cursorStyle",T.Line,"line",["line","block","underline","line-thin","block-outline","underline-thin"],(function(e){switch(e){case"line":return T.Line;case"block":return T.Block;case"underline":return T.Underline;case"line-thin":return T.LineThin;case"block-outline":return T.BlockOutline;case"underline-thin":return T.UnderlineThin}}),{description:l.kg("cursorStyle","Controls the cursor style.")})),cursorSurroundingLines:B(new b(29,"cursorSurroundingLines",0,0,1073741824,{description:l.kg("cursorSurroundingLines","Controls the minimal number of visible leading lines (minimum 0) and trailing lines (minimum 1) surrounding the cursor. Known as 'scrollOff' or 'scrollOffset' in some other editors.")})),cursorSurroundingLinesStyle:B(new L(30,"cursorSurroundingLinesStyle","default",["default","all"],{enumDescriptions:[l.kg("cursorSurroundingLinesStyle.default","`cursorSurroundingLines` is enforced only when triggered via the keyboard or API."),l.kg("cursorSurroundingLinesStyle.all","`cursorSurroundingLines` is enforced always.")],markdownDescription:l.kg("cursorSurroundingLinesStyle","Controls when `#editor.cursorSurroundingLines#` should be enforced.")})),cursorWidth:B(new b(31,"cursorWidth",0,0,1073741824,{markdownDescription:l.kg("cursorWidth","Controls the width of the cursor when `#editor.cursorStyle#` is set to `line`.")})),disableLayerHinting:B(new v(32,"disableLayerHinting",!1)),disableMonospaceOptimizations:B(new v(33,"disableMonospaceOptimizations",!1)),domReadOnly:B(new v(34,"domReadOnly",!1)),dragAndDrop:B(new v(35,"dragAndDrop",!0,{description:l.kg("dragAndDrop","Controls whether the editor should allow moving selections via drag and drop.")})),emptySelectionClipboard:B(new class extends v{constructor(){super(37,"emptySelectionClipboard",!0,{description:l.kg("emptySelectionClipboard","Controls whether copying without a selection copies the current line.")})}compute(e,t,i){return i&&e.emptySelectionClipboard}}),dropIntoEditor:B(new class extends u{constructor(){const e={enabled:!0,showDropSelector:"afterDrop"};super(36,"dropIntoEditor",e,{"editor.dropIntoEditor.enabled":{type:"boolean",default:e.enabled,markdownDescription:l.kg("dropIntoEditor.enabled","Controls whether you can drag and drop a file into a text editor by holding down the `Shift` key (instead of opening the file in an editor).")},"editor.dropIntoEditor.showDropSelector":{type:"string",markdownDescription:l.kg("dropIntoEditor.showDropSelector","Controls if a widget is shown when dropping files into the editor. This widget lets you control how the file is dropped."),enum:["afterDrop","never"],enumDescriptions:[l.kg("dropIntoEditor.showDropSelector.afterDrop","Show the drop selector widget after a file is dropped into the editor."),l.kg("dropIntoEditor.showDropSelector.never","Never show the drop selector widget. Instead the default drop provider is always used.")],default:"afterDrop"}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),showDropSelector:w(t.showDropSelector,this.defaultValue.showDropSelector,["afterDrop","never"])}}}),stickyScroll:B(new class extends u{constructor(){const e={enabled:!0,maxLineCount:5,defaultModel:"outlineModel",scrollWithEditor:!0};super(116,"stickyScroll",e,{"editor.stickyScroll.enabled":{type:"boolean",default:e.enabled,description:l.kg("editor.stickyScroll.enabled","Shows the nested current scopes during the scroll at the top of the editor."),tags:["experimental"]},"editor.stickyScroll.maxLineCount":{type:"number",default:e.maxLineCount,minimum:1,maximum:20,description:l.kg("editor.stickyScroll.maxLineCount","Defines the maximum number of sticky lines to show.")},"editor.stickyScroll.defaultModel":{type:"string",enum:["outlineModel","foldingProviderModel","indentationModel"],default:e.defaultModel,description:l.kg("editor.stickyScroll.defaultModel","Defines the model to use for determining which lines to stick. If the outline model does not exist, it will fall back on the folding provider model which falls back on the indentation model. This order is respected in all three cases.")},"editor.stickyScroll.scrollWithEditor":{type:"boolean",default:e.scrollWithEditor,description:l.kg("editor.stickyScroll.scrollWithEditor","Enable scrolling of Sticky Scroll with the editor's horizontal scrollbar.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),maxLineCount:b.clampedInt(t.maxLineCount,this.defaultValue.maxLineCount,1,20),defaultModel:w(t.defaultModel,this.defaultValue.defaultModel,["outlineModel","foldingProviderModel","indentationModel"]),scrollWithEditor:_(t.scrollWithEditor,this.defaultValue.scrollWithEditor)}}}),experimentalWhitespaceRendering:B(new L(38,"experimentalWhitespaceRendering","svg",["svg","font","off"],{enumDescriptions:[l.kg("experimentalWhitespaceRendering.svg","Use a new rendering method with svgs."),l.kg("experimentalWhitespaceRendering.font","Use a new rendering method with font characters."),l.kg("experimentalWhitespaceRendering.off","Use the stable rendering method.")],description:l.kg("experimentalWhitespaceRendering","Controls whether whitespace is rendered with a new, experimental method.")})),extraEditorClassName:B(new y(39,"extraEditorClassName","")),fastScrollSensitivity:B(new S(40,"fastScrollSensitivity",5,(e=>e<=0?5:e),{markdownDescription:l.kg("fastScrollSensitivity","Scrolling speed multiplier when pressing `Alt`.")})),find:B(new class extends u{constructor(){const e={cursorMoveOnType:!0,seedSearchStringFromSelection:"always",autoFindInSelection:"never",globalFindClipboard:!1,addExtraSpaceOnTop:!0,loop:!0};super(41,"find",e,{"editor.find.cursorMoveOnType":{type:"boolean",default:e.cursorMoveOnType,description:l.kg("find.cursorMoveOnType","Controls whether the cursor should jump to find matches while typing.")},"editor.find.seedSearchStringFromSelection":{type:"string",enum:["never","always","selection"],default:e.seedSearchStringFromSelection,enumDescriptions:[l.kg("editor.find.seedSearchStringFromSelection.never","Never seed search string from the editor selection."),l.kg("editor.find.seedSearchStringFromSelection.always","Always seed search string from the editor selection, including word at cursor position."),l.kg("editor.find.seedSearchStringFromSelection.selection","Only seed search string from the editor selection.")],description:l.kg("find.seedSearchStringFromSelection","Controls whether the search string in the Find Widget is seeded from the editor selection.")},"editor.find.autoFindInSelection":{type:"string",enum:["never","always","multiline"],default:e.autoFindInSelection,enumDescriptions:[l.kg("editor.find.autoFindInSelection.never","Never turn on Find in Selection automatically (default)."),l.kg("editor.find.autoFindInSelection.always","Always turn on Find in Selection automatically."),l.kg("editor.find.autoFindInSelection.multiline","Turn on Find in Selection automatically when multiple lines of content are selected.")],description:l.kg("find.autoFindInSelection","Controls the condition for turning on Find in Selection automatically.")},"editor.find.globalFindClipboard":{type:"boolean",default:e.globalFindClipboard,description:l.kg("find.globalFindClipboard","Controls whether the Find Widget should read or modify the shared find clipboard on macOS."),included:r.zx},"editor.find.addExtraSpaceOnTop":{type:"boolean",default:e.addExtraSpaceOnTop,description:l.kg("find.addExtraSpaceOnTop","Controls whether the Find Widget should add extra lines on top of the editor. When true, you can scroll beyond the first line when the Find Widget is visible.")},"editor.find.loop":{type:"boolean",default:e.loop,description:l.kg("find.loop","Controls whether the search automatically restarts from the beginning (or the end) when no further matches can be found.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{cursorMoveOnType:_(t.cursorMoveOnType,this.defaultValue.cursorMoveOnType),seedSearchStringFromSelection:"boolean"===typeof e.seedSearchStringFromSelection?e.seedSearchStringFromSelection?"always":"never":w(t.seedSearchStringFromSelection,this.defaultValue.seedSearchStringFromSelection,["never","always","selection"]),autoFindInSelection:"boolean"===typeof e.autoFindInSelection?e.autoFindInSelection?"always":"never":w(t.autoFindInSelection,this.defaultValue.autoFindInSelection,["never","always","multiline"]),globalFindClipboard:_(t.globalFindClipboard,this.defaultValue.globalFindClipboard),addExtraSpaceOnTop:_(t.addExtraSpaceOnTop,this.defaultValue.addExtraSpaceOnTop),loop:_(t.loop,this.defaultValue.loop)}}}),fixedOverflowWidgets:B(new v(42,"fixedOverflowWidgets",!1)),folding:B(new v(43,"folding",!0,{description:l.kg("folding","Controls whether the editor has code folding enabled.")})),foldingStrategy:B(new L(44,"foldingStrategy","auto",["auto","indentation"],{enumDescriptions:[l.kg("foldingStrategy.auto","Use a language-specific folding strategy if available, else the indentation-based one."),l.kg("foldingStrategy.indentation","Use the indentation-based folding strategy.")],description:l.kg("foldingStrategy","Controls the strategy for computing folding ranges.")})),foldingHighlight:B(new v(45,"foldingHighlight",!0,{description:l.kg("foldingHighlight","Controls whether the editor should highlight folded ranges.")})),foldingImportsByDefault:B(new v(46,"foldingImportsByDefault",!1,{description:l.kg("foldingImportsByDefault","Controls whether the editor automatically collapses import ranges.")})),foldingMaximumRegions:B(new b(47,"foldingMaximumRegions",5e3,10,65e3,{description:l.kg("foldingMaximumRegions","The maximum number of foldable regions. Increasing this value may result in the editor becoming less responsive when the current source has a large number of foldable regions.")})),unfoldOnClickAfterEndOfLine:B(new v(48,"unfoldOnClickAfterEndOfLine",!1,{description:l.kg("unfoldOnClickAfterEndOfLine","Controls whether clicking on the empty content after a folded line will unfold the line.")})),fontFamily:B(new y(49,"fontFamily",U.fontFamily,{description:l.kg("fontFamily","Controls the font family.")})),fontInfo:B(new class extends m{constructor(){super(50)}compute(e,t,i){return e.fontInfo}}),fontLigatures2:B(new k),fontSize:B(new class extends f{constructor(){super(52,"fontSize",U.fontSize,{type:"number",minimum:6,maximum:100,default:U.fontSize,description:l.kg("fontSize","Controls the font size in pixels.")})}validate(e){const t=S.float(e,this.defaultValue);return 0===t?U.fontSize:S.clamp(t,6,100)}compute(e,t,i){return e.fontInfo.fontSize}}),fontWeight:B(new N),fontVariations:B(new A),formatOnPaste:B(new v(55,"formatOnPaste",!1,{description:l.kg("formatOnPaste","Controls whether the editor should automatically format the pasted content. A formatter must be available and the formatter should be able to format a range in a document.")})),formatOnType:B(new v(56,"formatOnType",!1,{description:l.kg("formatOnType","Controls whether the editor should automatically format the line after typing.")})),glyphMargin:B(new v(57,"glyphMargin",!0,{description:l.kg("glyphMargin","Controls whether the editor should render the vertical glyph margin. Glyph margin is mostly used for debugging.")})),gotoLocation:B(new class extends u{constructor(){const e={multiple:"peek",multipleDefinitions:"peek",multipleTypeDefinitions:"peek",multipleDeclarations:"peek",multipleImplementations:"peek",multipleReferences:"peek",multipleTests:"peek",alternativeDefinitionCommand:"editor.action.goToReferences",alternativeTypeDefinitionCommand:"editor.action.goToReferences",alternativeDeclarationCommand:"editor.action.goToReferences",alternativeImplementationCommand:"",alternativeReferenceCommand:"",alternativeTestsCommand:""},t={type:"string",enum:["peek","gotoAndPeek","goto"],default:e.multiple,enumDescriptions:[l.kg("editor.gotoLocation.multiple.peek","Show Peek view of the results (default)"),l.kg("editor.gotoLocation.multiple.gotoAndPeek","Go to the primary result and show a Peek view"),l.kg("editor.gotoLocation.multiple.goto","Go to the primary result and enable Peek-less navigation to others")]},i=["","editor.action.referenceSearch.trigger","editor.action.goToReferences","editor.action.peekImplementation","editor.action.goToImplementation","editor.action.peekTypeDefinition","editor.action.goToTypeDefinition","editor.action.peekDeclaration","editor.action.revealDeclaration","editor.action.peekDefinition","editor.action.revealDefinitionAside","editor.action.revealDefinition"];super(58,"gotoLocation",e,{"editor.gotoLocation.multiple":{deprecationMessage:l.kg("editor.gotoLocation.multiple.deprecated","This setting is deprecated, please use separate settings like 'editor.editor.gotoLocation.multipleDefinitions' or 'editor.editor.gotoLocation.multipleImplementations' instead.")},"editor.gotoLocation.multipleDefinitions":{description:l.kg("editor.editor.gotoLocation.multipleDefinitions","Controls the behavior the 'Go to Definition'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleTypeDefinitions":{description:l.kg("editor.editor.gotoLocation.multipleTypeDefinitions","Controls the behavior the 'Go to Type Definition'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleDeclarations":{description:l.kg("editor.editor.gotoLocation.multipleDeclarations","Controls the behavior the 'Go to Declaration'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleImplementations":{description:l.kg("editor.editor.gotoLocation.multipleImplemenattions","Controls the behavior the 'Go to Implementations'-command when multiple target locations exist."),...t},"editor.gotoLocation.multipleReferences":{description:l.kg("editor.editor.gotoLocation.multipleReferences","Controls the behavior the 'Go to References'-command when multiple target locations exist."),...t},"editor.gotoLocation.alternativeDefinitionCommand":{type:"string",default:e.alternativeDefinitionCommand,enum:i,description:l.kg("alternativeDefinitionCommand","Alternative command id that is being executed when the result of 'Go to Definition' is the current location.")},"editor.gotoLocation.alternativeTypeDefinitionCommand":{type:"string",default:e.alternativeTypeDefinitionCommand,enum:i,description:l.kg("alternativeTypeDefinitionCommand","Alternative command id that is being executed when the result of 'Go to Type Definition' is the current location.")},"editor.gotoLocation.alternativeDeclarationCommand":{type:"string",default:e.alternativeDeclarationCommand,enum:i,description:l.kg("alternativeDeclarationCommand","Alternative command id that is being executed when the result of 'Go to Declaration' is the current location.")},"editor.gotoLocation.alternativeImplementationCommand":{type:"string",default:e.alternativeImplementationCommand,enum:i,description:l.kg("alternativeImplementationCommand","Alternative command id that is being executed when the result of 'Go to Implementation' is the current location.")},"editor.gotoLocation.alternativeReferenceCommand":{type:"string",default:e.alternativeReferenceCommand,enum:i,description:l.kg("alternativeReferenceCommand","Alternative command id that is being executed when the result of 'Go to Reference' is the current location.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{multiple:w(t.multiple,this.defaultValue.multiple,["peek","gotoAndPeek","goto"]),multipleDefinitions:t.multipleDefinitions??w(t.multipleDefinitions,"peek",["peek","gotoAndPeek","goto"]),multipleTypeDefinitions:t.multipleTypeDefinitions??w(t.multipleTypeDefinitions,"peek",["peek","gotoAndPeek","goto"]),multipleDeclarations:t.multipleDeclarations??w(t.multipleDeclarations,"peek",["peek","gotoAndPeek","goto"]),multipleImplementations:t.multipleImplementations??w(t.multipleImplementations,"peek",["peek","gotoAndPeek","goto"]),multipleReferences:t.multipleReferences??w(t.multipleReferences,"peek",["peek","gotoAndPeek","goto"]),multipleTests:t.multipleTests??w(t.multipleTests,"peek",["peek","gotoAndPeek","goto"]),alternativeDefinitionCommand:y.string(t.alternativeDefinitionCommand,this.defaultValue.alternativeDefinitionCommand),alternativeTypeDefinitionCommand:y.string(t.alternativeTypeDefinitionCommand,this.defaultValue.alternativeTypeDefinitionCommand),alternativeDeclarationCommand:y.string(t.alternativeDeclarationCommand,this.defaultValue.alternativeDeclarationCommand),alternativeImplementationCommand:y.string(t.alternativeImplementationCommand,this.defaultValue.alternativeImplementationCommand),alternativeReferenceCommand:y.string(t.alternativeReferenceCommand,this.defaultValue.alternativeReferenceCommand),alternativeTestsCommand:y.string(t.alternativeTestsCommand,this.defaultValue.alternativeTestsCommand)}}}),hideCursorInOverviewRuler:B(new v(59,"hideCursorInOverviewRuler",!1,{description:l.kg("hideCursorInOverviewRuler","Controls whether the cursor should be hidden in the overview ruler.")})),hover:B(new class extends u{constructor(){const e={enabled:!0,delay:300,hidingDelay:300,sticky:!0,above:!0};super(60,"hover",e,{"editor.hover.enabled":{type:"boolean",default:e.enabled,description:l.kg("hover.enabled","Controls whether the hover is shown.")},"editor.hover.delay":{type:"number",default:e.delay,minimum:0,maximum:1e4,description:l.kg("hover.delay","Controls the delay in milliseconds after which the hover is shown.")},"editor.hover.sticky":{type:"boolean",default:e.sticky,description:l.kg("hover.sticky","Controls whether the hover should remain visible when mouse is moved over it.")},"editor.hover.hidingDelay":{type:"integer",minimum:0,default:e.hidingDelay,description:l.kg("hover.hidingDelay","Controls the delay in milliseconds after which the hover is hidden. Requires `editor.hover.sticky` to be enabled.")},"editor.hover.above":{type:"boolean",default:e.above,description:l.kg("hover.above","Prefer showing hovers above the line, if there's space.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),delay:b.clampedInt(t.delay,this.defaultValue.delay,0,1e4),sticky:_(t.sticky,this.defaultValue.sticky),hidingDelay:b.clampedInt(t.hidingDelay,this.defaultValue.hidingDelay,0,6e5),above:_(t.above,this.defaultValue.above)}}}),inDiffEditor:B(new v(61,"inDiffEditor",!1)),letterSpacing:B(new S(64,"letterSpacing",U.letterSpacing,(e=>S.clamp(e,-5,20)),{description:l.kg("letterSpacing","Controls the letter spacing in pixels.")})),lightbulb:B(new class extends u{constructor(){const e={enabled:x.OnCode};super(65,"lightbulb",e,{"editor.lightbulb.enabled":{type:"string",tags:["experimental"],enum:[x.Off,x.OnCode,x.On],default:e.enabled,enumDescriptions:[l.kg("editor.lightbulb.enabled.off","Disable the code action menu."),l.kg("editor.lightbulb.enabled.onCode","Show the code action menu when the cursor is on lines with code."),l.kg("editor.lightbulb.enabled.on","Show the code action menu when the cursor is on lines with code or on empty lines.")],description:l.kg("enabled","Enables the Code Action lightbulb in the editor.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;return{enabled:w(e.enabled,this.defaultValue.enabled,[x.Off,x.OnCode,x.On])}}}),lineDecorationsWidth:B(new class extends u{constructor(){super(66,"lineDecorationsWidth",10)}validate(e){if("string"===typeof e&&/^\d+(\.\d+)?ch$/.test(e)){return-parseFloat(e.substring(0,e.length-2))}return b.clampedInt(e,this.defaultValue,0,1e3)}compute(e,t,i){return i<0?b.clampedInt(-i*e.fontInfo.typicalHalfwidthCharacterWidth,this.defaultValue,0,1e3):i}}),lineHeight:B(new class extends S{constructor(){super(67,"lineHeight",U.lineHeight,(e=>S.clamp(e,0,150)),{markdownDescription:l.kg("lineHeight","Controls the line height. \n - Use 0 to automatically compute the line height from the font size.\n - Values between 0 and 8 will be used as a multiplier with the font size.\n - Values greater than or equal to 8 will be used as effective values.")})}compute(e,t,i){return e.fontInfo.lineHeight}}),lineNumbers:B(new class extends u{constructor(){super(68,"lineNumbers",{renderType:1,renderFn:null},{type:"string",enum:["off","on","relative","interval"],enumDescriptions:[l.kg("lineNumbers.off","Line numbers are not rendered."),l.kg("lineNumbers.on","Line numbers are rendered as absolute number."),l.kg("lineNumbers.relative","Line numbers are rendered as distance in lines to cursor position."),l.kg("lineNumbers.interval","Line numbers are rendered every 10 lines.")],default:"on",description:l.kg("lineNumbers","Controls the display of line numbers.")})}validate(e){let t=this.defaultValue.renderType,i=this.defaultValue.renderFn;return"undefined"!==typeof e&&("function"===typeof e?(t=4,i=e):t="interval"===e?3:"relative"===e?2:"on"===e?1:0),{renderType:t,renderFn:i}}}),lineNumbersMinChars:B(new b(69,"lineNumbersMinChars",5,1,300)),linkedEditing:B(new v(70,"linkedEditing",!1,{description:l.kg("linkedEditing","Controls whether the editor has linked editing enabled. Depending on the language, related symbols such as HTML tags, are updated while editing.")})),links:B(new v(71,"links",!0,{description:l.kg("links","Controls whether the editor should detect links and make them clickable.")})),matchBrackets:B(new L(72,"matchBrackets","always",["always","near","never"],{description:l.kg("matchBrackets","Highlight matching brackets.")})),minimap:B(new class extends u{constructor(){const e={enabled:!0,size:"proportional",side:"right",showSlider:"mouseover",autohide:!1,renderCharacters:!0,maxColumn:120,scale:1,showRegionSectionHeaders:!0,showMarkSectionHeaders:!0,sectionHeaderFontSize:9,sectionHeaderLetterSpacing:1};super(73,"minimap",e,{"editor.minimap.enabled":{type:"boolean",default:e.enabled,description:l.kg("minimap.enabled","Controls whether the minimap is shown.")},"editor.minimap.autohide":{type:"boolean",default:e.autohide,description:l.kg("minimap.autohide","Controls whether the minimap is hidden automatically.")},"editor.minimap.size":{type:"string",enum:["proportional","fill","fit"],enumDescriptions:[l.kg("minimap.size.proportional","The minimap has the same size as the editor contents (and might scroll)."),l.kg("minimap.size.fill","The minimap will stretch or shrink as necessary to fill the height of the editor (no scrolling)."),l.kg("minimap.size.fit","The minimap will shrink as necessary to never be larger than the editor (no scrolling).")],default:e.size,description:l.kg("minimap.size","Controls the size of the minimap.")},"editor.minimap.side":{type:"string",enum:["left","right"],default:e.side,description:l.kg("minimap.side","Controls the side where to render the minimap.")},"editor.minimap.showSlider":{type:"string",enum:["always","mouseover"],default:e.showSlider,description:l.kg("minimap.showSlider","Controls when the minimap slider is shown.")},"editor.minimap.scale":{type:"number",default:e.scale,minimum:1,maximum:3,enum:[1,2,3],description:l.kg("minimap.scale","Scale of content drawn in the minimap: 1, 2 or 3.")},"editor.minimap.renderCharacters":{type:"boolean",default:e.renderCharacters,description:l.kg("minimap.renderCharacters","Render the actual characters on a line as opposed to color blocks.")},"editor.minimap.maxColumn":{type:"number",default:e.maxColumn,description:l.kg("minimap.maxColumn","Limit the width of the minimap to render at most a certain number of columns.")},"editor.minimap.showRegionSectionHeaders":{type:"boolean",default:e.showRegionSectionHeaders,description:l.kg("minimap.showRegionSectionHeaders","Controls whether named regions are shown as section headers in the minimap.")},"editor.minimap.showMarkSectionHeaders":{type:"boolean",default:e.showMarkSectionHeaders,description:l.kg("minimap.showMarkSectionHeaders","Controls whether MARK: comments are shown as section headers in the minimap.")},"editor.minimap.sectionHeaderFontSize":{type:"number",default:e.sectionHeaderFontSize,description:l.kg("minimap.sectionHeaderFontSize","Controls the font size of section headers in the minimap.")},"editor.minimap.sectionHeaderLetterSpacing":{type:"number",default:e.sectionHeaderLetterSpacing,description:l.kg("minimap.sectionHeaderLetterSpacing","Controls the amount of space (in pixels) between characters of section header. This helps the readability of the header in small font sizes.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),autohide:_(t.autohide,this.defaultValue.autohide),size:w(t.size,this.defaultValue.size,["proportional","fill","fit"]),side:w(t.side,this.defaultValue.side,["right","left"]),showSlider:w(t.showSlider,this.defaultValue.showSlider,["always","mouseover"]),renderCharacters:_(t.renderCharacters,this.defaultValue.renderCharacters),scale:b.clampedInt(t.scale,1,1,3),maxColumn:b.clampedInt(t.maxColumn,this.defaultValue.maxColumn,1,1e4),showRegionSectionHeaders:_(t.showRegionSectionHeaders,this.defaultValue.showRegionSectionHeaders),showMarkSectionHeaders:_(t.showMarkSectionHeaders,this.defaultValue.showMarkSectionHeaders),sectionHeaderFontSize:S.clamp(t.sectionHeaderFontSize??this.defaultValue.sectionHeaderFontSize,4,32),sectionHeaderLetterSpacing:S.clamp(t.sectionHeaderLetterSpacing??this.defaultValue.sectionHeaderLetterSpacing,0,5)}}}),mouseStyle:B(new L(74,"mouseStyle","text",["text","default","copy"])),mouseWheelScrollSensitivity:B(new S(75,"mouseWheelScrollSensitivity",1,(e=>0===e?1:e),{markdownDescription:l.kg("mouseWheelScrollSensitivity","A multiplier to be used on the `deltaX` and `deltaY` of mouse wheel scroll events.")})),mouseWheelZoom:B(new v(76,"mouseWheelZoom",!1,{markdownDescription:r.zx?l.kg("mouseWheelZoom.mac","Zoom the font of the editor when using mouse wheel and holding `Cmd`."):l.kg("mouseWheelZoom","Zoom the font of the editor when using mouse wheel and holding `Ctrl`.")})),multiCursorMergeOverlapping:B(new v(77,"multiCursorMergeOverlapping",!0,{description:l.kg("multiCursorMergeOverlapping","Merge multiple cursors when they are overlapping.")})),multiCursorModifier:B(new R(78,"multiCursorModifier","altKey","alt",["ctrlCmd","alt"],(function(e){return"ctrlCmd"===e?r.zx?"metaKey":"ctrlKey":"altKey"}),{markdownEnumDescriptions:[l.kg("multiCursorModifier.ctrlCmd","Maps to `Control` on Windows and Linux and to `Command` on macOS."),l.kg("multiCursorModifier.alt","Maps to `Alt` on Windows and Linux and to `Option` on macOS.")],markdownDescription:l.kg({key:"multiCursorModifier",comment:["- `ctrlCmd` refers to a value the setting can take and should not be localized.","- `Control` and `Command` refer to the modifier keys Ctrl or Cmd on the keyboard and can be localized."]},"The modifier to be used to add multiple cursors with the mouse. The Go to Definition and Open Link mouse gestures will adapt such that they do not conflict with the [multicursor modifier](https://code.visualstudio.com/docs/editor/codebasics#_multicursor-modifier).")})),multiCursorPaste:B(new L(79,"multiCursorPaste","spread",["spread","full"],{markdownEnumDescriptions:[l.kg("multiCursorPaste.spread","Each cursor pastes a single line of the text."),l.kg("multiCursorPaste.full","Each cursor pastes the full text.")],markdownDescription:l.kg("multiCursorPaste","Controls pasting when the line count of the pasted text matches the cursor count.")})),multiCursorLimit:B(new b(80,"multiCursorLimit",1e4,1,1e5,{markdownDescription:l.kg("multiCursorLimit","Controls the max number of cursors that can be in an active editor at once.")})),occurrencesHighlight:B(new L(81,"occurrencesHighlight","singleFile",["off","singleFile","multiFile"],{markdownEnumDescriptions:[l.kg("occurrencesHighlight.off","Does not highlight occurrences."),l.kg("occurrencesHighlight.singleFile","Highlights occurrences only in the current file."),l.kg("occurrencesHighlight.multiFile","Experimental: Highlights occurrences across all valid open files.")],markdownDescription:l.kg("occurrencesHighlight","Controls whether occurrences should be highlighted across open files.")})),overviewRulerBorder:B(new v(82,"overviewRulerBorder",!0,{description:l.kg("overviewRulerBorder","Controls whether a border should be drawn around the overview ruler.")})),overviewRulerLanes:B(new b(83,"overviewRulerLanes",3,0,3)),padding:B(new class extends u{constructor(){super(84,"padding",{top:0,bottom:0},{"editor.padding.top":{type:"number",default:0,minimum:0,maximum:1e3,description:l.kg("padding.top","Controls the amount of space between the top edge of the editor and the first line.")},"editor.padding.bottom":{type:"number",default:0,minimum:0,maximum:1e3,description:l.kg("padding.bottom","Controls the amount of space between the bottom edge of the editor and the last line.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{top:b.clampedInt(t.top,0,0,1e3),bottom:b.clampedInt(t.bottom,0,0,1e3)}}}),pasteAs:B(new class extends u{constructor(){const e={enabled:!0,showPasteSelector:"afterPaste"};super(85,"pasteAs",e,{"editor.pasteAs.enabled":{type:"boolean",default:e.enabled,markdownDescription:l.kg("pasteAs.enabled","Controls whether you can paste content in different ways.")},"editor.pasteAs.showPasteSelector":{type:"string",markdownDescription:l.kg("pasteAs.showPasteSelector","Controls if a widget is shown when pasting content in to the editor. This widget lets you control how the file is pasted."),enum:["afterPaste","never"],enumDescriptions:[l.kg("pasteAs.showPasteSelector.afterPaste","Show the paste selector widget after content is pasted into the editor."),l.kg("pasteAs.showPasteSelector.never","Never show the paste selector widget. Instead the default pasting behavior is always used.")],default:"afterPaste"}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),showPasteSelector:w(t.showPasteSelector,this.defaultValue.showPasteSelector,["afterPaste","never"])}}}),parameterHints:B(new class extends u{constructor(){const e={enabled:!0,cycle:!0};super(86,"parameterHints",e,{"editor.parameterHints.enabled":{type:"boolean",default:e.enabled,description:l.kg("parameterHints.enabled","Enables a pop-up that shows parameter documentation and type information as you type.")},"editor.parameterHints.cycle":{type:"boolean",default:e.cycle,description:l.kg("parameterHints.cycle","Controls whether the parameter hints menu cycles or closes when reaching the end of the list.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),cycle:_(t.cycle,this.defaultValue.cycle)}}}),peekWidgetDefaultFocus:B(new L(87,"peekWidgetDefaultFocus","tree",["tree","editor"],{enumDescriptions:[l.kg("peekWidgetDefaultFocus.tree","Focus the tree when opening peek"),l.kg("peekWidgetDefaultFocus.editor","Focus the editor when opening peek")],description:l.kg("peekWidgetDefaultFocus","Controls whether to focus the inline editor or the tree in the peek widget.")})),placeholder:B(new class extends u{constructor(){super(88,"placeholder",void 0)}validate(e){return"undefined"===typeof e?this.defaultValue:"string"===typeof e?e:this.defaultValue}}),definitionLinkOpensInPeek:B(new v(89,"definitionLinkOpensInPeek",!1,{description:l.kg("definitionLinkOpensInPeek","Controls whether the Go to Definition mouse gesture always opens the peek widget.")})),quickSuggestions:B(new class extends u{constructor(){const e={other:"on",comments:"off",strings:"off"},t=[{type:"boolean"},{type:"string",enum:["on","inline","off"],enumDescriptions:[l.kg("on","Quick suggestions show inside the suggest widget"),l.kg("inline","Quick suggestions show as ghost text"),l.kg("off","Quick suggestions are disabled")]}];super(90,"quickSuggestions",e,{type:"object",additionalProperties:!1,properties:{strings:{anyOf:t,default:e.strings,description:l.kg("quickSuggestions.strings","Enable quick suggestions inside strings.")},comments:{anyOf:t,default:e.comments,description:l.kg("quickSuggestions.comments","Enable quick suggestions inside comments.")},other:{anyOf:t,default:e.other,description:l.kg("quickSuggestions.other","Enable quick suggestions outside of strings and comments.")}},default:e,markdownDescription:l.kg("quickSuggestions","Controls whether suggestions should automatically show up while typing. This can be controlled for typing in comments, strings, and other code. Quick suggestion can be configured to show as ghost text or with the suggest widget. Also be aware of the {0}-setting which controls if suggestions are triggered by special characters.","`#editor.suggestOnTriggerCharacters#`")}),this.defaultValue=e}validate(e){if("boolean"===typeof e){const t=e?"on":"off";return{comments:t,strings:t,other:t}}if(!e||"object"!==typeof e)return this.defaultValue;const{other:t,comments:i,strings:s}=e,n=["on","inline","off"];let r,o,a;return r="boolean"===typeof t?t?"on":"off":w(t,this.defaultValue.other,n),o="boolean"===typeof i?i?"on":"off":w(i,this.defaultValue.comments,n),a="boolean"===typeof s?s?"on":"off":w(s,this.defaultValue.strings,n),{other:r,comments:o,strings:a}}}),quickSuggestionsDelay:B(new b(91,"quickSuggestionsDelay",10,0,1073741824,{description:l.kg("quickSuggestionsDelay","Controls the delay in milliseconds after which quick suggestions will show up.")})),readOnly:B(new v(92,"readOnly",!1)),readOnlyMessage:B(new class extends u{constructor(){super(93,"readOnlyMessage",undefined)}validate(e){return e&&"object"===typeof e?e:this.defaultValue}}),renameOnType:B(new v(94,"renameOnType",!1,{description:l.kg("renameOnType","Controls whether the editor auto renames on type."),markdownDeprecationMessage:l.kg("renameOnTypeDeprecate","Deprecated, use `editor.linkedEditing` instead.")})),renderControlCharacters:B(new v(95,"renderControlCharacters",!0,{description:l.kg("renderControlCharacters","Controls whether the editor should render control characters."),restricted:!0})),renderFinalNewline:B(new L(96,"renderFinalNewline",r.j9?"dimmed":"on",["off","on","dimmed"],{description:l.kg("renderFinalNewline","Render last line number when the file ends with a newline.")})),renderLineHighlight:B(new L(97,"renderLineHighlight","line",["none","gutter","line","all"],{enumDescriptions:["","","",l.kg("renderLineHighlight.all","Highlights both the gutter and the current line.")],description:l.kg("renderLineHighlight","Controls how the editor should render the current line highlight.")})),renderLineHighlightOnlyWhenFocus:B(new v(98,"renderLineHighlightOnlyWhenFocus",!1,{description:l.kg("renderLineHighlightOnlyWhenFocus","Controls if the editor should render the current line highlight only when the editor is focused.")})),renderValidationDecorations:B(new L(99,"renderValidationDecorations","editable",["editable","on","off"])),renderWhitespace:B(new L(100,"renderWhitespace","selection",["none","boundary","selection","trailing","all"],{enumDescriptions:["",l.kg("renderWhitespace.boundary","Render whitespace characters except for single spaces between words."),l.kg("renderWhitespace.selection","Render whitespace characters only on selected text."),l.kg("renderWhitespace.trailing","Render only trailing whitespace characters."),""],description:l.kg("renderWhitespace","Controls how the editor should render whitespace characters.")})),revealHorizontalRightPadding:B(new b(101,"revealHorizontalRightPadding",15,0,1e3)),roundedSelection:B(new v(102,"roundedSelection",!0,{description:l.kg("roundedSelection","Controls whether selections should have rounded corners.")})),rulers:B(new class extends u{constructor(){const e=[],t={type:"number",description:l.kg("rulers.size","Number of monospace characters at which this editor ruler will render.")};super(103,"rulers",e,{type:"array",items:{anyOf:[t,{type:["object"],properties:{column:t,color:{type:"string",description:l.kg("rulers.color","Color of this editor ruler."),format:"color-hex"}}}]},default:e,description:l.kg("rulers","Render vertical rulers after a certain number of monospace characters. Use multiple values for multiple rulers. No rulers are drawn if array is empty.")})}validate(e){if(Array.isArray(e)){const t=[];for(const i of e)if("number"===typeof i)t.push({column:b.clampedInt(i,0,0,1e4),color:null});else if(i&&"object"===typeof i){const e=i;t.push({column:b.clampedInt(e.column,0,0,1e4),color:e.color})}return t.sort(((e,t)=>e.column-t.column)),t}return this.defaultValue}}),scrollbar:B(new class extends u{constructor(){const e={vertical:1,horizontal:1,arrowSize:11,useShadows:!0,verticalHasArrows:!1,horizontalHasArrows:!1,horizontalScrollbarSize:12,horizontalSliderSize:12,verticalScrollbarSize:14,verticalSliderSize:14,handleMouseWheel:!0,alwaysConsumeMouseWheel:!0,scrollByPage:!1,ignoreHorizontalScrollbarInContentHeight:!1};super(104,"scrollbar",e,{"editor.scrollbar.vertical":{type:"string",enum:["auto","visible","hidden"],enumDescriptions:[l.kg("scrollbar.vertical.auto","The vertical scrollbar will be visible only when necessary."),l.kg("scrollbar.vertical.visible","The vertical scrollbar will always be visible."),l.kg("scrollbar.vertical.fit","The vertical scrollbar will always be hidden.")],default:"auto",description:l.kg("scrollbar.vertical","Controls the visibility of the vertical scrollbar.")},"editor.scrollbar.horizontal":{type:"string",enum:["auto","visible","hidden"],enumDescriptions:[l.kg("scrollbar.horizontal.auto","The horizontal scrollbar will be visible only when necessary."),l.kg("scrollbar.horizontal.visible","The horizontal scrollbar will always be visible."),l.kg("scrollbar.horizontal.fit","The horizontal scrollbar will always be hidden.")],default:"auto",description:l.kg("scrollbar.horizontal","Controls the visibility of the horizontal scrollbar.")},"editor.scrollbar.verticalScrollbarSize":{type:"number",default:e.verticalScrollbarSize,description:l.kg("scrollbar.verticalScrollbarSize","The width of the vertical scrollbar.")},"editor.scrollbar.horizontalScrollbarSize":{type:"number",default:e.horizontalScrollbarSize,description:l.kg("scrollbar.horizontalScrollbarSize","The height of the horizontal scrollbar.")},"editor.scrollbar.scrollByPage":{type:"boolean",default:e.scrollByPage,description:l.kg("scrollbar.scrollByPage","Controls whether clicks scroll by page or jump to click position.")},"editor.scrollbar.ignoreHorizontalScrollbarInContentHeight":{type:"boolean",default:e.ignoreHorizontalScrollbarInContentHeight,description:l.kg("scrollbar.ignoreHorizontalScrollbarInContentHeight","When set, the horizontal scrollbar will not increase the size of the editor's content.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e,i=b.clampedInt(t.horizontalScrollbarSize,this.defaultValue.horizontalScrollbarSize,0,1e3),s=b.clampedInt(t.verticalScrollbarSize,this.defaultValue.verticalScrollbarSize,0,1e3);return{arrowSize:b.clampedInt(t.arrowSize,this.defaultValue.arrowSize,0,1e3),vertical:D(t.vertical,this.defaultValue.vertical),horizontal:D(t.horizontal,this.defaultValue.horizontal),useShadows:_(t.useShadows,this.defaultValue.useShadows),verticalHasArrows:_(t.verticalHasArrows,this.defaultValue.verticalHasArrows),horizontalHasArrows:_(t.horizontalHasArrows,this.defaultValue.horizontalHasArrows),handleMouseWheel:_(t.handleMouseWheel,this.defaultValue.handleMouseWheel),alwaysConsumeMouseWheel:_(t.alwaysConsumeMouseWheel,this.defaultValue.alwaysConsumeMouseWheel),horizontalScrollbarSize:i,horizontalSliderSize:b.clampedInt(t.horizontalSliderSize,i,0,1e3),verticalScrollbarSize:s,verticalSliderSize:b.clampedInt(t.verticalSliderSize,s,0,1e3),scrollByPage:_(t.scrollByPage,this.defaultValue.scrollByPage),ignoreHorizontalScrollbarInContentHeight:_(t.ignoreHorizontalScrollbarInContentHeight,this.defaultValue.ignoreHorizontalScrollbarInContentHeight)}}}),scrollBeyondLastColumn:B(new b(105,"scrollBeyondLastColumn",4,0,1073741824,{description:l.kg("scrollBeyondLastColumn","Controls the number of extra characters beyond which the editor will scroll horizontally.")})),scrollBeyondLastLine:B(new v(106,"scrollBeyondLastLine",!0,{description:l.kg("scrollBeyondLastLine","Controls whether the editor will scroll beyond the last line.")})),scrollPredominantAxis:B(new v(107,"scrollPredominantAxis",!0,{description:l.kg("scrollPredominantAxis","Scroll only along the predominant axis when scrolling both vertically and horizontally at the same time. Prevents horizontal drift when scrolling vertically on a trackpad.")})),selectionClipboard:B(new v(108,"selectionClipboard",!0,{description:l.kg("selectionClipboard","Controls whether the Linux primary clipboard should be supported."),included:r.j9})),selectionHighlight:B(new v(109,"selectionHighlight",!0,{description:l.kg("selectionHighlight","Controls whether the editor should highlight matches similar to the selection.")})),selectOnLineNumbers:B(new v(110,"selectOnLineNumbers",!0)),showFoldingControls:B(new L(111,"showFoldingControls","mouseover",["always","never","mouseover"],{enumDescriptions:[l.kg("showFoldingControls.always","Always show the folding controls."),l.kg("showFoldingControls.never","Never show the folding controls and reduce the gutter size."),l.kg("showFoldingControls.mouseover","Only show the folding controls when the mouse is over the gutter.")],description:l.kg("showFoldingControls","Controls when the folding controls on the gutter are shown.")})),showUnused:B(new v(112,"showUnused",!0,{description:l.kg("showUnused","Controls fading out of unused code.")})),showDeprecated:B(new v(141,"showDeprecated",!0,{description:l.kg("showDeprecated","Controls strikethrough deprecated variables.")})),inlayHints:B(new class extends u{constructor(){const e={enabled:"on",fontSize:0,fontFamily:"",padding:!1};super(142,"inlayHints",e,{"editor.inlayHints.enabled":{type:"string",default:e.enabled,description:l.kg("inlayHints.enable","Enables the inlay hints in the editor."),enum:["on","onUnlessPressed","offUnlessPressed","off"],markdownEnumDescriptions:[l.kg("editor.inlayHints.on","Inlay hints are enabled"),l.kg("editor.inlayHints.onUnlessPressed","Inlay hints are showing by default and hide when holding {0}",r.zx?"Ctrl+Option":"Ctrl+Alt"),l.kg("editor.inlayHints.offUnlessPressed","Inlay hints are hidden by default and show when holding {0}",r.zx?"Ctrl+Option":"Ctrl+Alt"),l.kg("editor.inlayHints.off","Inlay hints are disabled")]},"editor.inlayHints.fontSize":{type:"number",default:e.fontSize,markdownDescription:l.kg("inlayHints.fontSize","Controls font size of inlay hints in the editor. As default the {0} is used when the configured value is less than {1} or greater than the editor font size.","`#editor.fontSize#`","`5`")},"editor.inlayHints.fontFamily":{type:"string",default:e.fontFamily,markdownDescription:l.kg("inlayHints.fontFamily","Controls font family of inlay hints in the editor. When set to empty, the {0} is used.","`#editor.fontFamily#`")},"editor.inlayHints.padding":{type:"boolean",default:e.padding,description:l.kg("inlayHints.padding","Enables the padding around the inlay hints in the editor.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return"boolean"===typeof t.enabled&&(t.enabled=t.enabled?"on":"off"),{enabled:w(t.enabled,this.defaultValue.enabled,["on","off","offUnlessPressed","onUnlessPressed"]),fontSize:b.clampedInt(t.fontSize,this.defaultValue.fontSize,0,100),fontFamily:y.string(t.fontFamily,this.defaultValue.fontFamily),padding:_(t.padding,this.defaultValue.padding)}}}),snippetSuggestions:B(new L(113,"snippetSuggestions","inline",["top","bottom","inline","none"],{enumDescriptions:[l.kg("snippetSuggestions.top","Show snippet suggestions on top of other suggestions."),l.kg("snippetSuggestions.bottom","Show snippet suggestions below other suggestions."),l.kg("snippetSuggestions.inline","Show snippets suggestions with other suggestions."),l.kg("snippetSuggestions.none","Do not show snippet suggestions.")],description:l.kg("snippetSuggestions","Controls whether snippets are shown with other suggestions and how they are sorted.")})),smartSelect:B(new class extends u{constructor(){super(114,"smartSelect",{selectLeadingAndTrailingWhitespace:!0,selectSubwords:!0},{"editor.smartSelect.selectLeadingAndTrailingWhitespace":{description:l.kg("selectLeadingAndTrailingWhitespace","Whether leading and trailing whitespace should always be selected."),default:!0,type:"boolean"},"editor.smartSelect.selectSubwords":{description:l.kg("selectSubwords","Whether subwords (like 'foo' in 'fooBar' or 'foo_bar') should be selected."),default:!0,type:"boolean"}})}validate(e){return e&&"object"===typeof e?{selectLeadingAndTrailingWhitespace:_(e.selectLeadingAndTrailingWhitespace,this.defaultValue.selectLeadingAndTrailingWhitespace),selectSubwords:_(e.selectSubwords,this.defaultValue.selectSubwords)}:this.defaultValue}}),smoothScrolling:B(new v(115,"smoothScrolling",!1,{description:l.kg("smoothScrolling","Controls whether the editor will scroll using an animation.")})),stopRenderingLineAfter:B(new b(118,"stopRenderingLineAfter",1e4,-1,1073741824)),suggest:B(new class extends u{constructor(){const e={insertMode:"insert",filterGraceful:!0,snippetsPreventQuickSuggestions:!1,localityBonus:!1,shareSuggestSelections:!1,selectionMode:"always",showIcons:!0,showStatusBar:!1,preview:!1,previewMode:"subwordSmart",showInlineDetails:!0,showMethods:!0,showFunctions:!0,showConstructors:!0,showDeprecated:!0,matchOnWordStartOnly:!0,showFields:!0,showVariables:!0,showClasses:!0,showStructs:!0,showInterfaces:!0,showModules:!0,showProperties:!0,showEvents:!0,showOperators:!0,showUnits:!0,showValues:!0,showConstants:!0,showEnums:!0,showEnumMembers:!0,showKeywords:!0,showWords:!0,showColors:!0,showFiles:!0,showReferences:!0,showFolders:!0,showTypeParameters:!0,showSnippets:!0,showUsers:!0,showIssues:!0};super(119,"suggest",e,{"editor.suggest.insertMode":{type:"string",enum:["insert","replace"],enumDescriptions:[l.kg("suggest.insertMode.insert","Insert suggestion without overwriting text right of the cursor."),l.kg("suggest.insertMode.replace","Insert suggestion and overwrite text right of the cursor.")],default:e.insertMode,description:l.kg("suggest.insertMode","Controls whether words are overwritten when accepting completions. Note that this depends on extensions opting into this feature.")},"editor.suggest.filterGraceful":{type:"boolean",default:e.filterGraceful,description:l.kg("suggest.filterGraceful","Controls whether filtering and sorting suggestions accounts for small typos.")},"editor.suggest.localityBonus":{type:"boolean",default:e.localityBonus,description:l.kg("suggest.localityBonus","Controls whether sorting favors words that appear close to the cursor.")},"editor.suggest.shareSuggestSelections":{type:"boolean",default:e.shareSuggestSelections,markdownDescription:l.kg("suggest.shareSuggestSelections","Controls whether remembered suggestion selections are shared between multiple workspaces and windows (needs `#editor.suggestSelection#`).")},"editor.suggest.selectionMode":{type:"string",enum:["always","never","whenTriggerCharacter","whenQuickSuggestion"],enumDescriptions:[l.kg("suggest.insertMode.always","Always select a suggestion when automatically triggering IntelliSense."),l.kg("suggest.insertMode.never","Never select a suggestion when automatically triggering IntelliSense."),l.kg("suggest.insertMode.whenTriggerCharacter","Select a suggestion only when triggering IntelliSense from a trigger character."),l.kg("suggest.insertMode.whenQuickSuggestion","Select a suggestion only when triggering IntelliSense as you type.")],default:e.selectionMode,markdownDescription:l.kg("suggest.selectionMode","Controls whether a suggestion is selected when the widget shows. Note that this only applies to automatically triggered suggestions ({0} and {1}) and that a suggestion is always selected when explicitly invoked, e.g via `Ctrl+Space`.","`#editor.quickSuggestions#`","`#editor.suggestOnTriggerCharacters#`")},"editor.suggest.snippetsPreventQuickSuggestions":{type:"boolean",default:e.snippetsPreventQuickSuggestions,description:l.kg("suggest.snippetsPreventQuickSuggestions","Controls whether an active snippet prevents quick suggestions.")},"editor.suggest.showIcons":{type:"boolean",default:e.showIcons,description:l.kg("suggest.showIcons","Controls whether to show or hide icons in suggestions.")},"editor.suggest.showStatusBar":{type:"boolean",default:e.showStatusBar,description:l.kg("suggest.showStatusBar","Controls the visibility of the status bar at the bottom of the suggest widget.")},"editor.suggest.preview":{type:"boolean",default:e.preview,description:l.kg("suggest.preview","Controls whether to preview the suggestion outcome in the editor.")},"editor.suggest.showInlineDetails":{type:"boolean",default:e.showInlineDetails,description:l.kg("suggest.showInlineDetails","Controls whether suggest details show inline with the label or only in the details widget.")},"editor.suggest.maxVisibleSuggestions":{type:"number",deprecationMessage:l.kg("suggest.maxVisibleSuggestions.dep","This setting is deprecated. The suggest widget can now be resized.")},"editor.suggest.filteredTypes":{type:"object",deprecationMessage:l.kg("deprecated","This setting is deprecated, please use separate settings like 'editor.suggest.showKeywords' or 'editor.suggest.showSnippets' instead.")},"editor.suggest.showMethods":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showMethods","When enabled IntelliSense shows `method`-suggestions.")},"editor.suggest.showFunctions":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showFunctions","When enabled IntelliSense shows `function`-suggestions.")},"editor.suggest.showConstructors":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showConstructors","When enabled IntelliSense shows `constructor`-suggestions.")},"editor.suggest.showDeprecated":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showDeprecated","When enabled IntelliSense shows `deprecated`-suggestions.")},"editor.suggest.matchOnWordStartOnly":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.matchOnWordStartOnly","When enabled IntelliSense filtering requires that the first character matches on a word start. For example, `c` on `Console` or `WebContext` but _not_ on `description`. When disabled IntelliSense will show more results but still sorts them by match quality.")},"editor.suggest.showFields":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showFields","When enabled IntelliSense shows `field`-suggestions.")},"editor.suggest.showVariables":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showVariables","When enabled IntelliSense shows `variable`-suggestions.")},"editor.suggest.showClasses":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showClasss","When enabled IntelliSense shows `class`-suggestions.")},"editor.suggest.showStructs":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showStructs","When enabled IntelliSense shows `struct`-suggestions.")},"editor.suggest.showInterfaces":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showInterfaces","When enabled IntelliSense shows `interface`-suggestions.")},"editor.suggest.showModules":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showModules","When enabled IntelliSense shows `module`-suggestions.")},"editor.suggest.showProperties":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showPropertys","When enabled IntelliSense shows `property`-suggestions.")},"editor.suggest.showEvents":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showEvents","When enabled IntelliSense shows `event`-suggestions.")},"editor.suggest.showOperators":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showOperators","When enabled IntelliSense shows `operator`-suggestions.")},"editor.suggest.showUnits":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showUnits","When enabled IntelliSense shows `unit`-suggestions.")},"editor.suggest.showValues":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showValues","When enabled IntelliSense shows `value`-suggestions.")},"editor.suggest.showConstants":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showConstants","When enabled IntelliSense shows `constant`-suggestions.")},"editor.suggest.showEnums":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showEnums","When enabled IntelliSense shows `enum`-suggestions.")},"editor.suggest.showEnumMembers":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showEnumMembers","When enabled IntelliSense shows `enumMember`-suggestions.")},"editor.suggest.showKeywords":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showKeywords","When enabled IntelliSense shows `keyword`-suggestions.")},"editor.suggest.showWords":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showTexts","When enabled IntelliSense shows `text`-suggestions.")},"editor.suggest.showColors":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showColors","When enabled IntelliSense shows `color`-suggestions.")},"editor.suggest.showFiles":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showFiles","When enabled IntelliSense shows `file`-suggestions.")},"editor.suggest.showReferences":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showReferences","When enabled IntelliSense shows `reference`-suggestions.")},"editor.suggest.showCustomcolors":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showCustomcolors","When enabled IntelliSense shows `customcolor`-suggestions.")},"editor.suggest.showFolders":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showFolders","When enabled IntelliSense shows `folder`-suggestions.")},"editor.suggest.showTypeParameters":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showTypeParameters","When enabled IntelliSense shows `typeParameter`-suggestions.")},"editor.suggest.showSnippets":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showSnippets","When enabled IntelliSense shows `snippet`-suggestions.")},"editor.suggest.showUsers":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showUsers","When enabled IntelliSense shows `user`-suggestions.")},"editor.suggest.showIssues":{type:"boolean",default:!0,markdownDescription:l.kg("editor.suggest.showIssues","When enabled IntelliSense shows `issues`-suggestions.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{insertMode:w(t.insertMode,this.defaultValue.insertMode,["insert","replace"]),filterGraceful:_(t.filterGraceful,this.defaultValue.filterGraceful),snippetsPreventQuickSuggestions:_(t.snippetsPreventQuickSuggestions,this.defaultValue.filterGraceful),localityBonus:_(t.localityBonus,this.defaultValue.localityBonus),shareSuggestSelections:_(t.shareSuggestSelections,this.defaultValue.shareSuggestSelections),selectionMode:w(t.selectionMode,this.defaultValue.selectionMode,["always","never","whenQuickSuggestion","whenTriggerCharacter"]),showIcons:_(t.showIcons,this.defaultValue.showIcons),showStatusBar:_(t.showStatusBar,this.defaultValue.showStatusBar),preview:_(t.preview,this.defaultValue.preview),previewMode:w(t.previewMode,this.defaultValue.previewMode,["prefix","subword","subwordSmart"]),showInlineDetails:_(t.showInlineDetails,this.defaultValue.showInlineDetails),showMethods:_(t.showMethods,this.defaultValue.showMethods),showFunctions:_(t.showFunctions,this.defaultValue.showFunctions),showConstructors:_(t.showConstructors,this.defaultValue.showConstructors),showDeprecated:_(t.showDeprecated,this.defaultValue.showDeprecated),matchOnWordStartOnly:_(t.matchOnWordStartOnly,this.defaultValue.matchOnWordStartOnly),showFields:_(t.showFields,this.defaultValue.showFields),showVariables:_(t.showVariables,this.defaultValue.showVariables),showClasses:_(t.showClasses,this.defaultValue.showClasses),showStructs:_(t.showStructs,this.defaultValue.showStructs),showInterfaces:_(t.showInterfaces,this.defaultValue.showInterfaces),showModules:_(t.showModules,this.defaultValue.showModules),showProperties:_(t.showProperties,this.defaultValue.showProperties),showEvents:_(t.showEvents,this.defaultValue.showEvents),showOperators:_(t.showOperators,this.defaultValue.showOperators),showUnits:_(t.showUnits,this.defaultValue.showUnits),showValues:_(t.showValues,this.defaultValue.showValues),showConstants:_(t.showConstants,this.defaultValue.showConstants),showEnums:_(t.showEnums,this.defaultValue.showEnums),showEnumMembers:_(t.showEnumMembers,this.defaultValue.showEnumMembers),showKeywords:_(t.showKeywords,this.defaultValue.showKeywords),showWords:_(t.showWords,this.defaultValue.showWords),showColors:_(t.showColors,this.defaultValue.showColors),showFiles:_(t.showFiles,this.defaultValue.showFiles),showReferences:_(t.showReferences,this.defaultValue.showReferences),showFolders:_(t.showFolders,this.defaultValue.showFolders),showTypeParameters:_(t.showTypeParameters,this.defaultValue.showTypeParameters),showSnippets:_(t.showSnippets,this.defaultValue.showSnippets),showUsers:_(t.showUsers,this.defaultValue.showUsers),showIssues:_(t.showIssues,this.defaultValue.showIssues)}}}),inlineSuggest:B(new class extends u{constructor(){const e={enabled:!0,mode:"subwordSmart",showToolbar:"onHover",suppressSuggestions:!1,keepOnBlur:!1,fontFamily:"default"};super(62,"inlineSuggest",e,{"editor.inlineSuggest.enabled":{type:"boolean",default:e.enabled,description:l.kg("inlineSuggest.enabled","Controls whether to automatically show inline suggestions in the editor.")},"editor.inlineSuggest.showToolbar":{type:"string",default:e.showToolbar,enum:["always","onHover","never"],enumDescriptions:[l.kg("inlineSuggest.showToolbar.always","Show the inline suggestion toolbar whenever an inline suggestion is shown."),l.kg("inlineSuggest.showToolbar.onHover","Show the inline suggestion toolbar when hovering over an inline suggestion."),l.kg("inlineSuggest.showToolbar.never","Never show the inline suggestion toolbar.")],description:l.kg("inlineSuggest.showToolbar","Controls when to show the inline suggestion toolbar.")},"editor.inlineSuggest.suppressSuggestions":{type:"boolean",default:e.suppressSuggestions,description:l.kg("inlineSuggest.suppressSuggestions","Controls how inline suggestions interact with the suggest widget. If enabled, the suggest widget is not shown automatically when inline suggestions are available.")},"editor.inlineSuggest.fontFamily":{type:"string",default:e.fontFamily,description:l.kg("inlineSuggest.fontFamily","Controls the font family of the inline suggestions.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),mode:w(t.mode,this.defaultValue.mode,["prefix","subword","subwordSmart"]),showToolbar:w(t.showToolbar,this.defaultValue.showToolbar,["always","onHover","never"]),suppressSuggestions:_(t.suppressSuggestions,this.defaultValue.suppressSuggestions),keepOnBlur:_(t.keepOnBlur,this.defaultValue.keepOnBlur),fontFamily:y.string(t.fontFamily,this.defaultValue.fontFamily)}}}),inlineEdit:B(new class extends u{constructor(){const e={enabled:!1,showToolbar:"onHover",fontFamily:"default",keepOnBlur:!1};super(63,"experimentalInlineEdit",e,{"editor.experimentalInlineEdit.enabled":{type:"boolean",default:e.enabled,description:l.kg("inlineEdit.enabled","Controls whether to show inline edits in the editor.")},"editor.experimentalInlineEdit.showToolbar":{type:"string",default:e.showToolbar,enum:["always","onHover","never"],enumDescriptions:[l.kg("inlineEdit.showToolbar.always","Show the inline edit toolbar whenever an inline suggestion is shown."),l.kg("inlineEdit.showToolbar.onHover","Show the inline edit toolbar when hovering over an inline suggestion."),l.kg("inlineEdit.showToolbar.never","Never show the inline edit toolbar.")],description:l.kg("inlineEdit.showToolbar","Controls when to show the inline edit toolbar.")},"editor.experimentalInlineEdit.fontFamily":{type:"string",default:e.fontFamily,description:l.kg("inlineEdit.fontFamily","Controls the font family of the inline edit.")}})}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{enabled:_(t.enabled,this.defaultValue.enabled),showToolbar:w(t.showToolbar,this.defaultValue.showToolbar,["always","onHover","never"]),fontFamily:y.string(t.fontFamily,this.defaultValue.fontFamily),keepOnBlur:_(t.keepOnBlur,this.defaultValue.keepOnBlur)}}}),inlineCompletionsAccessibilityVerbose:B(new v(150,"inlineCompletionsAccessibilityVerbose",!1,{description:l.kg("inlineCompletionsAccessibilityVerbose","Controls whether the accessibility hint should be provided to screen reader users when an inline completion is shown.")})),suggestFontSize:B(new b(120,"suggestFontSize",0,0,1e3,{markdownDescription:l.kg("suggestFontSize","Font size for the suggest widget. When set to {0}, the value of {1} is used.","`0`","`#editor.fontSize#`")})),suggestLineHeight:B(new b(121,"suggestLineHeight",0,0,1e3,{markdownDescription:l.kg("suggestLineHeight","Line height for the suggest widget. When set to {0}, the value of {1} is used. The minimum value is 8.","`0`","`#editor.lineHeight#`")})),suggestOnTriggerCharacters:B(new v(122,"suggestOnTriggerCharacters",!0,{description:l.kg("suggestOnTriggerCharacters","Controls whether suggestions should automatically show up when typing trigger characters.")})),suggestSelection:B(new L(123,"suggestSelection","first",["first","recentlyUsed","recentlyUsedByPrefix"],{markdownEnumDescriptions:[l.kg("suggestSelection.first","Always select the first suggestion."),l.kg("suggestSelection.recentlyUsed","Select recent suggestions unless further typing selects one, e.g. `console.| -> console.log` because `log` has been completed recently."),l.kg("suggestSelection.recentlyUsedByPrefix","Select suggestions based on previous prefixes that have completed those suggestions, e.g. `co -> console` and `con -> const`.")],description:l.kg("suggestSelection","Controls how suggestions are pre-selected when showing the suggest list.")})),tabCompletion:B(new L(124,"tabCompletion","off",["on","off","onlySnippets"],{enumDescriptions:[l.kg("tabCompletion.on","Tab complete will insert the best matching suggestion when pressing tab."),l.kg("tabCompletion.off","Disable tab completions."),l.kg("tabCompletion.onlySnippets","Tab complete snippets when their prefix match. Works best when 'quickSuggestions' aren't enabled.")],description:l.kg("tabCompletion","Enables tab completions.")})),tabIndex:B(new b(125,"tabIndex",0,-1,1073741824)),unicodeHighlight:B(new class extends u{constructor(){const e={nonBasicASCII:M,invisibleCharacters:!0,ambiguousCharacters:!0,includeComments:M,includeStrings:!0,allowedCharacters:{},allowedLocales:{_os:!0,_vscode:!0}};super(126,"unicodeHighlight",e,{[P.nonBasicASCII]:{restricted:!0,type:["boolean","string"],enum:[!0,!1,M],default:e.nonBasicASCII,description:l.kg("unicodeHighlight.nonBasicASCII","Controls whether all non-basic ASCII characters are highlighted. Only characters between U+0020 and U+007E, tab, line-feed and carriage-return are considered basic ASCII.")},[P.invisibleCharacters]:{restricted:!0,type:"boolean",default:e.invisibleCharacters,description:l.kg("unicodeHighlight.invisibleCharacters","Controls whether characters that just reserve space or have no width at all are highlighted.")},[P.ambiguousCharacters]:{restricted:!0,type:"boolean",default:e.ambiguousCharacters,description:l.kg("unicodeHighlight.ambiguousCharacters","Controls whether characters are highlighted that can be confused with basic ASCII characters, except those that are common in the current user locale.")},[P.includeComments]:{restricted:!0,type:["boolean","string"],enum:[!0,!1,M],default:e.includeComments,description:l.kg("unicodeHighlight.includeComments","Controls whether characters in comments should also be subject to Unicode highlighting.")},[P.includeStrings]:{restricted:!0,type:["boolean","string"],enum:[!0,!1,M],default:e.includeStrings,description:l.kg("unicodeHighlight.includeStrings","Controls whether characters in strings should also be subject to Unicode highlighting.")},[P.allowedCharacters]:{restricted:!0,type:"object",default:e.allowedCharacters,description:l.kg("unicodeHighlight.allowedCharacters","Defines allowed characters that are not being highlighted."),additionalProperties:{type:"boolean"}},[P.allowedLocales]:{restricted:!0,type:"object",additionalProperties:{type:"boolean"},default:e.allowedLocales,description:l.kg("unicodeHighlight.allowedLocales","Unicode characters that are common in allowed locales are not being highlighted.")}})}applyUpdate(e,t){let i=!1;t.allowedCharacters&&e&&(n.aI(e.allowedCharacters,t.allowedCharacters)||(e={...e,allowedCharacters:t.allowedCharacters},i=!0)),t.allowedLocales&&e&&(n.aI(e.allowedLocales,t.allowedLocales)||(e={...e,allowedLocales:t.allowedLocales},i=!0));const s=super.applyUpdate(e,t);return i?new g(s.newValue,!0):s}validate(e){if(!e||"object"!==typeof e)return this.defaultValue;const t=e;return{nonBasicASCII:F(t.nonBasicASCII,M,[!0,!1,M]),invisibleCharacters:_(t.invisibleCharacters,this.defaultValue.invisibleCharacters),ambiguousCharacters:_(t.ambiguousCharacters,this.defaultValue.ambiguousCharacters),includeComments:F(t.includeComments,M,[!0,!1,M]),includeStrings:F(t.includeStrings,M,[!0,!1,M]),allowedCharacters:this.validateBooleanMap(e.allowedCharacters,this.defaultValue.allowedCharacters),allowedLocales:this.validateBooleanMap(e.allowedLocales,this.defaultValue.allowedLocales)}}validateBooleanMap(e,t){if("object"!==typeof e||!e)return t;const i={};for(const[s,n]of Object.entries(e))!0===n&&(i[s]=!0);return i}}),unusualLineTerminators:B(new L(127,"unusualLineTerminators","prompt",["auto","off","prompt"],{enumDescriptions:[l.kg("unusualLineTerminators.auto","Unusual line terminators are automatically removed."),l.kg("unusualLineTerminators.off","Unusual line terminators are ignored."),l.kg("unusualLineTerminators.prompt","Unusual line terminators prompt to be removed.")],description:l.kg("unusualLineTerminators","Remove unusual line terminators that might cause problems.")})),useShadowDOM:B(new v(128,"useShadowDOM",!0)),useTabStops:B(new v(129,"useTabStops",!0,{description:l.kg("useTabStops","Spaces and tabs are inserted and deleted in alignment with tab stops.")})),wordBreak:B(new L(130,"wordBreak","normal",["normal","keepAll"],{markdownEnumDescriptions:[l.kg("wordBreak.normal","Use the default line break rule."),l.kg("wordBreak.keepAll","Word breaks should not be used for Chinese/Japanese/Korean (CJK) text. Non-CJK text behavior is the same as for normal.")],description:l.kg("wordBreak","Controls the word break rules used for Chinese/Japanese/Korean (CJK) text.")})),wordSegmenterLocales:B(new class extends u{constructor(){super(131,"wordSegmenterLocales",[],{anyOf:[{description:l.kg("wordSegmenterLocales","Locales to be used for word segmentation when doing word related navigations or operations. Specify the BCP 47 language tag of the word you wish to recognize (e.g., ja, zh-CN, zh-Hant-TW, etc.)."),type:"string"},{description:l.kg("wordSegmenterLocales","Locales to be used for word segmentation when doing word related navigations or operations. Specify the BCP 47 language tag of the word you wish to recognize (e.g., ja, zh-CN, zh-Hant-TW, etc.)."),type:"array",items:{type:"string"}}]})}validate(e){if("string"===typeof e&&(e=[e]),Array.isArray(e)){const t=[];for(const i of e)if("string"===typeof i)try{Intl.Segmenter.supportedLocalesOf(i).length>0&&t.push(i)}catch{}return t}return this.defaultValue}}),wordSeparators:B(new y(132,"wordSeparators",a.J3,{description:l.kg("wordSeparators","Characters that will be used as word separators when doing word related navigations or operations.")})),wordWrap:B(new L(133,"wordWrap","off",["off","on","wordWrapColumn","bounded"],{markdownEnumDescriptions:[l.kg("wordWrap.off","Lines will never wrap."),l.kg("wordWrap.on","Lines will wrap at the viewport width."),l.kg({key:"wordWrap.wordWrapColumn",comment:["- `editor.wordWrapColumn` refers to a different setting and should not be localized."]},"Lines will wrap at `#editor.wordWrapColumn#`."),l.kg({key:"wordWrap.bounded",comment:["- viewport means the edge of the visible window size.","- `editor.wordWrapColumn` refers to a different setting and should not be localized."]},"Lines will wrap at the minimum of viewport and `#editor.wordWrapColumn#`.")],description:l.kg({key:"wordWrap",comment:["- 'off', 'on', 'wordWrapColumn' and 'bounded' refer to values the setting can take and should not be localized.","- `editor.wordWrapColumn` refers to a different setting and should not be localized."]},"Controls how lines should wrap.")})),wordWrapBreakAfterCharacters:B(new y(134,"wordWrapBreakAfterCharacters"," \t})]?|/&.,;\xa2\xb0\u2032\u2033\u2030\u2103\u3001\u3002\uff61\uff64\uffe0\uff0c\uff0e\uff1a\uff1b\uff1f\uff01\uff05\u30fb\uff65\u309d\u309e\u30fd\u30fe\u30fc\u30a1\u30a3\u30a5\u30a7\u30a9\u30c3\u30e3\u30e5\u30e7\u30ee\u30f5\u30f6\u3041\u3043\u3045\u3047\u3049\u3063\u3083\u3085\u3087\u308e\u3095\u3096\u31f0\u31f1\u31f2\u31f3\u31f4\u31f5\u31f6\u31f7\u31f8\u31f9\u31fa\u31fb\u31fc\u31fd\u31fe\u31ff\u3005\u303b\uff67\uff68\uff69\uff6a\uff6b\uff6c\uff6d\uff6e\uff6f\uff70\u201d\u3009\u300b\u300d\u300f\u3011\u3015\uff09\uff3d\uff5d\uff63")),wordWrapBreakBeforeCharacters:B(new y(135,"wordWrapBreakBeforeCharacters","([{\u2018\u201c\u3008\u300a\u300c\u300e\u3010\u3014\uff08\uff3b\uff5b\uff62\xa3\xa5\uff04\uffe1\uffe5+\uff0b")),wordWrapColumn:B(new b(136,"wordWrapColumn",80,1,1073741824,{markdownDescription:l.kg({key:"wordWrapColumn",comment:["- `editor.wordWrap` refers to a different setting and should not be localized.","- 'wordWrapColumn' and 'bounded' refer to values the different setting can take and should not be localized."]},"Controls the wrapping column of the editor when `#editor.wordWrap#` is `wordWrapColumn` or `bounded`.")})),wordWrapOverride1:B(new L(137,"wordWrapOverride1","inherit",["off","on","inherit"])),wordWrapOverride2:B(new L(138,"wordWrapOverride2","inherit",["off","on","inherit"])),editorClassName:B(new class extends m{constructor(){super(143)}compute(e,t,i){const s=["monaco-editor"];return t.get(39)&&s.push(t.get(39)),e.extraEditorClassName&&s.push(e.extraEditorClassName),"default"===t.get(74)?s.push("mouse-default"):"copy"===t.get(74)&&s.push("mouse-copy"),t.get(112)&&s.push("showUnused"),t.get(141)&&s.push("showDeprecated"),s.join(" ")}}),defaultColorDecorators:B(new v(148,"defaultColorDecorators",!1,{markdownDescription:l.kg("defaultColorDecorators","Controls whether inline color decorations should be shown using the default document color provider")})),pixelRatio:B(new class extends m{constructor(){super(144)}compute(e,t,i){return e.pixelRatio}}),tabFocusMode:B(new v(145,"tabFocusMode",!1,{markdownDescription:l.kg("tabFocusMode","Controls whether the editor receives tabs or defers them to the workbench for navigation.")})),layoutInfo:B(new I),wrappingInfo:B(new class extends m{constructor(){super(147)}compute(e,t,i){const s=t.get(146);return{isDominatedByLongLines:e.isDominatedByLongLines,isWordWrapMinified:s.isWordWrapMinified,isViewportWrapping:s.isViewportWrapping,wrappingColumn:s.wrappingColumn}}}),wrappingIndent:B(new class extends u{constructor(){super(139,"wrappingIndent",1,{"editor.wrappingIndent":{type:"string",enum:["none","same","indent","deepIndent"],enumDescriptions:[l.kg("wrappingIndent.none","No indentation. Wrapped lines begin at column 1."),l.kg("wrappingIndent.same","Wrapped lines get the same indentation as the parent."),l.kg("wrappingIndent.indent","Wrapped lines get +1 indentation toward the parent."),l.kg("wrappingIndent.deepIndent","Wrapped lines get +2 indentation toward the parent.")],description:l.kg("wrappingIndent","Controls the indentation of wrapped lines."),default:"same"}})}validate(e){switch(e){case"none":return 0;case"same":return 1;case"indent":return 2;case"deepIndent":return 3}return 1}compute(e,t,i){return 2===t.get(2)?0:i}}),wrappingStrategy:B(new class extends u{constructor(){super(140,"wrappingStrategy","simple",{"editor.wrappingStrategy":{enumDescriptions:[l.kg("wrappingStrategy.simple","Assumes that all characters are of the same width. This is a fast algorithm that works correctly for monospace fonts and certain scripts (like Latin characters) where glyphs are of equal width."),l.kg("wrappingStrategy.advanced","Delegates wrapping points computation to the browser. This is a slow algorithm, that might cause freezes for large files, but it works correctly in all cases.")],type:"string",enum:["simple","advanced"],default:"simple",description:l.kg("wrappingStrategy","Controls the algorithm that computes wrapping points. Note that when in accessibility mode, advanced will be used for the best experience.")}})}validate(e){return w(e,"simple",["simple","advanced"])}compute(e,t,i){return 2===t.get(2)?"advanced":i}})}},79027:(e,t,i)=>{"use strict";i.d(t,{D:()=>n});var s=i(41234);const n=new class{constructor(){this._zoomLevel=0,this._onDidChangeZoomLevel=new s.vl,this.onDidChangeZoomLevel=this._onDidChangeZoomLevel.event}getZoomLevel(){return this._zoomLevel}setZoomLevel(e){e=Math.min(Math.max(-5,e),20),this._zoomLevel!==e&&(this._zoomLevel=e,this._onDidChangeZoomLevel.fire(this._zoomLevel))}}},74196:(e,t,i)=>{"use strict";i.d(t,{YJ:()=>l,_8:()=>a});var s=i(98067),n=i(87908),r=i(79027);const o=s.zx?1.5:1.35;class a{static createFromValidatedSettings(e,t,i){const s=e.get(49),n=e.get(53),r=e.get(52),o=e.get(51),l=e.get(54),c=e.get(67),h=e.get(64);return a._create(s,n,r,o,l,c,h,t,i)}static _create(e,t,i,s,l,c,h,d,u){0===c?c=o*i:c<8&&(c*=i),(c=Math.round(c))<8&&(c=8);const g=1+(u?0:.1*r.D.getZoomLevel());if(i*=g,c*=g,l===n.r_.TRANSLATE)if("normal"===t||"bold"===t)l=n.r_.OFF;else{l=`'wght' ${parseInt(t,10)}`,t="normal"}return new a({pixelRatio:d,fontFamily:e,fontWeight:t,fontSize:i,fontFeatureSettings:s,fontVariationSettings:l,lineHeight:c,letterSpacing:h})}constructor(e){this._bareFontInfoBrand=void 0,this.pixelRatio=e.pixelRatio,this.fontFamily=String(e.fontFamily),this.fontWeight=String(e.fontWeight),this.fontSize=e.fontSize,this.fontFeatureSettings=e.fontFeatureSettings,this.fontVariationSettings=e.fontVariationSettings,this.lineHeight=0|e.lineHeight,this.letterSpacing=e.letterSpacing}getId(){return`${this.pixelRatio}-${this.fontFamily}-${this.fontWeight}-${this.fontSize}-${this.fontFeatureSettings}-${this.fontVariationSettings}-${this.lineHeight}-${this.letterSpacing}`}getMassagedFontFamily(){const e=n.jU.fontFamily,t=a._wrapInQuotes(this.fontFamily);return e&&this.fontFamily!==e?`${t}, ${e}`:t}static _wrapInQuotes(e){return/[,"']/.test(e)?e:/[+ ]/.test(e)?`"${e}"`:e}}class l extends a{constructor(e,t){super(e),this._editorStylingBrand=void 0,this.version=2,this.isTrusted=t,this.isMonospace=e.isMonospace,this.typicalHalfwidthCharacterWidth=e.typicalHalfwidthCharacterWidth,this.typicalFullwidthCharacterWidth=e.typicalFullwidthCharacterWidth,this.canUseHalfwidthRightwardsArrow=e.canUseHalfwidthRightwardsArrow,this.spaceWidth=e.spaceWidth,this.middotWidth=e.middotWidth,this.wsmiddotWidth=e.wsmiddotWidth,this.maxDigitWidth=e.maxDigitWidth}equals(e){return this.fontFamily===e.fontFamily&&this.fontWeight===e.fontWeight&&this.fontSize===e.fontSize&&this.fontFeatureSettings===e.fontFeatureSettings&&this.fontVariationSettings===e.fontVariationSettings&&this.lineHeight===e.lineHeight&&this.letterSpacing===e.letterSpacing&&this.typicalHalfwidthCharacterWidth===e.typicalHalfwidthCharacterWidth&&this.typicalFullwidthCharacterWidth===e.typicalFullwidthCharacterWidth&&this.canUseHalfwidthRightwardsArrow===e.canUseHalfwidthRightwardsArrow&&this.spaceWidth===e.spaceWidth&&this.middotWidth===e.middotWidth&&this.wsmiddotWidth===e.wsmiddotWidth&&this.maxDigitWidth===e.maxDigitWidth}}},60534:(e,t,i)=>{"use strict";i.d(t,{V:()=>n,y:()=>r});var s=i(85152);class n{constructor(e){const t=(0,s.W)(e);this._defaultValue=t,this._asciiMap=n._createAsciiMap(t),this._map=new Map}static _createAsciiMap(e){const t=new Uint8Array(256);return t.fill(e),t}set(e,t){const i=(0,s.W)(t);e>=0&&e<256?this._asciiMap[e]=i:this._map.set(e,i)}get(e){return e>=0&&e<256?this._asciiMap[e]:this._map.get(e)||this._defaultValue}clear(){this._asciiMap.fill(this._defaultValue),this._map.clear()}}class r{constructor(){this._actual=new n(0)}add(e){this._actual.set(e,1)}has(e){return 1===this._actual.get(e)}clear(){return this._actual.clear()}}},1245:(e,t,i)=>{"use strict";i.d(t,{A:()=>n});var s=i(91508);class n{static _nextVisibleColumn(e,t,i){return 9===e?n.nextRenderTabStop(t,i):s.ne(e)||s.Ss(e)?t+2:t+1}static visibleColumnFromColumn(e,t,i){const n=Math.min(t-1,e.length),r=e.substring(0,n),o=new s.km(r);let a=0;for(;!o.eol();){const e=s.Z5(r,n,o.offset);o.nextGraphemeLength(),a=this._nextVisibleColumn(e,a,i)}return a}static columnFromVisibleColumn(e,t,i){if(t<=0)return 1;const n=e.length,r=new s.km(e);let o=0,a=1;for(;!r.eol();){const l=s.Z5(e,n,r.offset);r.nextGraphemeLength();const c=this._nextVisibleColumn(l,o,i),h=r.offset+1;if(c>=t){return c-t{"use strict";i.d(t,{k:()=>n});var s=i(36677);class n{static insert(e,t){return{range:new s.Q(e.lineNumber,e.column,e.lineNumber,e.column),text:t,forceMoveMarkers:!0}}static delete(e){return{range:e,text:null}}static replace(e,t){return{range:e,text:t}}static replaceMove(e,t){return{range:e,text:t,forceMoveMarkers:!0}}}},87119:(e,t,i)=>{"use strict";i.d(t,{A3:()=>x,AQ:()=>W,Am:()=>R,As:()=>A,BD:()=>J,Bo:()=>X,CM:()=>w,D0:()=>c,Ek:()=>P,H0:()=>L,I2:()=>Q,IW:()=>ee,If:()=>Z,JB:()=>I,L0:()=>p,Mf:()=>l,P1:()=>re,Pe:()=>se,Qt:()=>f,WD:()=>ne,WS:()=>ie,WY:()=>oe,Xr:()=>D,aZ:()=>B,bB:()=>te,hz:()=>E,je:()=>u,kG:()=>a,kM:()=>h,l5:()=>j,lQ:()=>z,n4:()=>$,ob:()=>b,ow:()=>S,s7:()=>q,sC:()=>d,sH:()=>K,sN:()=>V,ss:()=>G,tK:()=>T,tp:()=>k,vP:()=>y,vV:()=>C,vp:()=>U,w4:()=>m,we:()=>g,x9:()=>O,yI:()=>H,yw:()=>M,zp:()=>Y});var s=i(78209),n=i(47661),r=i(66261),o=i(47612);const a=(0,r.x1A)("editor.lineHighlightBackground",null,s.kg("lineHighlight","Background color for the highlight of line at the cursor position.")),l=(0,r.x1A)("editor.lineHighlightBorder",{dark:"#282828",light:"#eeeeee",hcDark:"#f38518",hcLight:r.b1q},s.kg("lineHighlightBorderBox","Background color for the border around the line at the cursor position.")),c=((0,r.x1A)("editor.rangeHighlightBackground",{dark:"#ffffff0b",light:"#fdff0033",hcDark:null,hcLight:null},s.kg("rangeHighlight","Background color of highlighted ranges, like by quick open and find features. The color must not be opaque so as not to hide underlying decorations."),!0),(0,r.x1A)("editor.rangeHighlightBorder",{dark:null,light:null,hcDark:r.buw,hcLight:r.buw},s.kg("rangeHighlightBorder","Background color of the border around highlighted ranges.")),(0,r.x1A)("editor.symbolHighlightBackground",{dark:r.Ubg,light:r.Ubg,hcDark:null,hcLight:null},s.kg("symbolHighlight","Background color of highlighted symbol, like for go to definition or go next/previous symbol. The color must not be opaque so as not to hide underlying decorations."),!0),(0,r.x1A)("editor.symbolHighlightBorder",{dark:null,light:null,hcDark:r.buw,hcLight:r.buw},s.kg("symbolHighlightBorder","Background color of the border around highlighted symbols.")),(0,r.x1A)("editorCursor.foreground",{dark:"#AEAFAD",light:n.Q1.black,hcDark:n.Q1.white,hcLight:"#0F4A85"},s.kg("caret","Color of the editor cursor."))),h=(0,r.x1A)("editorCursor.background",null,s.kg("editorCursorBackground","The background color of the editor cursor. Allows customizing the color of a character overlapped by a block cursor.")),d=(0,r.x1A)("editorMultiCursor.primary.foreground",c,s.kg("editorMultiCursorPrimaryForeground","Color of the primary editor cursor when multiple cursors are present.")),u=(0,r.x1A)("editorMultiCursor.primary.background",h,s.kg("editorMultiCursorPrimaryBackground","The background color of the primary editor cursor when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),g=(0,r.x1A)("editorMultiCursor.secondary.foreground",c,s.kg("editorMultiCursorSecondaryForeground","Color of secondary editor cursors when multiple cursors are present.")),p=(0,r.x1A)("editorMultiCursor.secondary.background",h,s.kg("editorMultiCursorSecondaryBackground","The background color of secondary editor cursors when multiple cursors are present. Allows customizing the color of a character overlapped by a block cursor.")),m=(0,r.x1A)("editorWhitespace.foreground",{dark:"#e3e4e229",light:"#33333333",hcDark:"#e3e4e229",hcLight:"#CCCCCC"},s.kg("editorWhitespaces","Color of whitespace characters in the editor.")),f=(0,r.x1A)("editorLineNumber.foreground",{dark:"#858585",light:"#237893",hcDark:n.Q1.white,hcLight:"#292929"},s.kg("editorLineNumbers","Color of editor line numbers.")),_=(0,r.x1A)("editorIndentGuide.background",m,s.kg("editorIndentGuides","Color of the editor indentation guides."),!1,s.kg("deprecatedEditorIndentGuides","'editorIndentGuide.background' is deprecated. Use 'editorIndentGuide.background1' instead.")),v=(0,r.x1A)("editorIndentGuide.activeBackground",m,s.kg("editorActiveIndentGuide","Color of the active editor indentation guides."),!1,s.kg("deprecatedEditorActiveIndentGuide","'editorIndentGuide.activeBackground' is deprecated. Use 'editorIndentGuide.activeBackground1' instead.")),C=(0,r.x1A)("editorIndentGuide.background1",_,s.kg("editorIndentGuides1","Color of the editor indentation guides (1).")),b=(0,r.x1A)("editorIndentGuide.background2","#00000000",s.kg("editorIndentGuides2","Color of the editor indentation guides (2).")),E=(0,r.x1A)("editorIndentGuide.background3","#00000000",s.kg("editorIndentGuides3","Color of the editor indentation guides (3).")),S=(0,r.x1A)("editorIndentGuide.background4","#00000000",s.kg("editorIndentGuides4","Color of the editor indentation guides (4).")),y=(0,r.x1A)("editorIndentGuide.background5","#00000000",s.kg("editorIndentGuides5","Color of the editor indentation guides (5).")),w=(0,r.x1A)("editorIndentGuide.background6","#00000000",s.kg("editorIndentGuides6","Color of the editor indentation guides (6).")),L=(0,r.x1A)("editorIndentGuide.activeBackground1",v,s.kg("editorActiveIndentGuide1","Color of the active editor indentation guides (1).")),R=(0,r.x1A)("editorIndentGuide.activeBackground2","#00000000",s.kg("editorActiveIndentGuide2","Color of the active editor indentation guides (2).")),T=(0,r.x1A)("editorIndentGuide.activeBackground3","#00000000",s.kg("editorActiveIndentGuide3","Color of the active editor indentation guides (3).")),x=(0,r.x1A)("editorIndentGuide.activeBackground4","#00000000",s.kg("editorActiveIndentGuide4","Color of the active editor indentation guides (4).")),k=(0,r.x1A)("editorIndentGuide.activeBackground5","#00000000",s.kg("editorActiveIndentGuide5","Color of the active editor indentation guides (5).")),A=(0,r.x1A)("editorIndentGuide.activeBackground6","#00000000",s.kg("editorActiveIndentGuide6","Color of the active editor indentation guides (6).")),N=(0,r.x1A)("editorActiveLineNumber.foreground",{dark:"#c6c6c6",light:"#0B216F",hcDark:r.buw,hcLight:r.buw},s.kg("editorActiveLineNumber","Color of editor active line number"),!1,s.kg("deprecatedEditorActiveLineNumber","Id is deprecated. Use 'editorLineNumber.activeForeground' instead.")),I=((0,r.x1A)("editorLineNumber.activeForeground",N,s.kg("editorActiveLineNumber","Color of editor active line number")),(0,r.x1A)("editorLineNumber.dimmedForeground",null,s.kg("editorDimmedLineNumber","Color of the final editor line when editor.renderFinalNewline is set to dimmed."))),O=((0,r.x1A)("editorRuler.foreground",{dark:"#5A5A5A",light:n.Q1.lightgrey,hcDark:n.Q1.white,hcLight:"#292929"},s.kg("editorRuler","Color of the editor rulers.")),(0,r.x1A)("editorCodeLens.foreground",{dark:"#999999",light:"#919191",hcDark:"#999999",hcLight:"#292929"},s.kg("editorCodeLensForeground","Foreground color of editor CodeLens")),(0,r.x1A)("editorBracketMatch.background",{dark:"#0064001a",light:"#0064001a",hcDark:"#0064001a",hcLight:"#0000"},s.kg("editorBracketMatchBackground","Background color behind matching brackets")),(0,r.x1A)("editorBracketMatch.border",{dark:"#888",light:"#B9B9B9",hcDark:r.b1q,hcLight:r.b1q},s.kg("editorBracketMatchBorder","Color for matching brackets boxes")),(0,r.x1A)("editorOverviewRuler.border",{dark:"#7f7f7f4d",light:"#7f7f7f4d",hcDark:"#7f7f7f4d",hcLight:"#666666"},s.kg("editorOverviewRulerBorder","Color of the overview ruler border."))),D=(0,r.x1A)("editorOverviewRuler.background",null,s.kg("editorOverviewRulerBackground","Background color of the editor overview ruler.")),M=((0,r.x1A)("editorGutter.background",r.YtV,s.kg("editorGutter","Background color of the editor gutter. The gutter contains the glyph margins and the line numbers.")),(0,r.x1A)("editorUnnecessaryCode.border",{dark:null,light:null,hcDark:n.Q1.fromHex("#fff").transparent(.8),hcLight:r.b1q},s.kg("unnecessaryCodeBorder","Border color of unnecessary (unused) source code in the editor.")),(0,r.x1A)("editorUnnecessaryCode.opacity",{dark:n.Q1.fromHex("#000a"),light:n.Q1.fromHex("#0007"),hcDark:null,hcLight:null},s.kg("unnecessaryCodeOpacity","Opacity of unnecessary (unused) source code in the editor. For example, \"#000000c0\" will render the code with 75% opacity. For high contrast themes, use the 'editorUnnecessaryCode.border' theme color to underline unnecessary code instead of fading it out."))),P=((0,r.x1A)("editorGhostText.border",{dark:null,light:null,hcDark:n.Q1.fromHex("#fff").transparent(.8),hcLight:n.Q1.fromHex("#292929").transparent(.8)},s.kg("editorGhostTextBorder","Border color of ghost text in the editor.")),(0,r.x1A)("editorGhostText.foreground",{dark:n.Q1.fromHex("#ffffff56"),light:n.Q1.fromHex("#0007"),hcDark:null,hcLight:null},s.kg("editorGhostTextForeground","Foreground color of the ghost text in the editor."))),F=((0,r.x1A)("editorGhostText.background",null,s.kg("editorGhostTextBackground","Background color of the ghost text in the editor.")),new n.Q1(new n.bU(0,122,204,.6))),U=(0,r.x1A)("editorOverviewRuler.rangeHighlightForeground",F,s.kg("overviewRulerRangeHighlight","Overview ruler marker color for range highlights. The color must not be opaque so as not to hide underlying decorations."),!0),H=(0,r.x1A)("editorOverviewRuler.errorForeground",{dark:new n.Q1(new n.bU(255,18,18,.7)),light:new n.Q1(new n.bU(255,18,18,.7)),hcDark:new n.Q1(new n.bU(255,50,50,1)),hcLight:"#B5200D"},s.kg("overviewRuleError","Overview ruler marker color for errors.")),B=(0,r.x1A)("editorOverviewRuler.warningForeground",{dark:r.Hng,light:r.Hng,hcDark:r.Stt,hcLight:r.Stt},s.kg("overviewRuleWarning","Overview ruler marker color for warnings.")),W=(0,r.x1A)("editorOverviewRuler.infoForeground",{dark:r.pOz,light:r.pOz,hcDark:r.IIb,hcLight:r.IIb},s.kg("overviewRuleInfo","Overview ruler marker color for infos.")),V=(0,r.x1A)("editorBracketHighlight.foreground1",{dark:"#FFD700",light:"#0431FAFF",hcDark:"#FFD700",hcLight:"#0431FAFF"},s.kg("editorBracketHighlightForeground1","Foreground color of brackets (1). Requires enabling bracket pair colorization.")),z=(0,r.x1A)("editorBracketHighlight.foreground2",{dark:"#DA70D6",light:"#319331FF",hcDark:"#DA70D6",hcLight:"#319331FF"},s.kg("editorBracketHighlightForeground2","Foreground color of brackets (2). Requires enabling bracket pair colorization.")),G=(0,r.x1A)("editorBracketHighlight.foreground3",{dark:"#179FFF",light:"#7B3814FF",hcDark:"#87CEFA",hcLight:"#7B3814FF"},s.kg("editorBracketHighlightForeground3","Foreground color of brackets (3). Requires enabling bracket pair colorization.")),j=(0,r.x1A)("editorBracketHighlight.foreground4","#00000000",s.kg("editorBracketHighlightForeground4","Foreground color of brackets (4). Requires enabling bracket pair colorization.")),K=(0,r.x1A)("editorBracketHighlight.foreground5","#00000000",s.kg("editorBracketHighlightForeground5","Foreground color of brackets (5). Requires enabling bracket pair colorization.")),Y=(0,r.x1A)("editorBracketHighlight.foreground6","#00000000",s.kg("editorBracketHighlightForeground6","Foreground color of brackets (6). Requires enabling bracket pair colorization.")),q=(0,r.x1A)("editorBracketHighlight.unexpectedBracket.foreground",{dark:new n.Q1(new n.bU(255,18,18,.8)),light:new n.Q1(new n.bU(255,18,18,.8)),hcDark:"new Color(new RGBA(255, 50, 50, 1))",hcLight:"#B5200D"},s.kg("editorBracketHighlightUnexpectedBracketForeground","Foreground color of unexpected brackets.")),$=(0,r.x1A)("editorBracketPairGuide.background1","#00000000",s.kg("editorBracketPairGuide.background1","Background color of inactive bracket pair guides (1). Requires enabling bracket pair guides.")),Q=(0,r.x1A)("editorBracketPairGuide.background2","#00000000",s.kg("editorBracketPairGuide.background2","Background color of inactive bracket pair guides (2). Requires enabling bracket pair guides.")),X=(0,r.x1A)("editorBracketPairGuide.background3","#00000000",s.kg("editorBracketPairGuide.background3","Background color of inactive bracket pair guides (3). Requires enabling bracket pair guides.")),Z=(0,r.x1A)("editorBracketPairGuide.background4","#00000000",s.kg("editorBracketPairGuide.background4","Background color of inactive bracket pair guides (4). Requires enabling bracket pair guides.")),J=(0,r.x1A)("editorBracketPairGuide.background5","#00000000",s.kg("editorBracketPairGuide.background5","Background color of inactive bracket pair guides (5). Requires enabling bracket pair guides.")),ee=(0,r.x1A)("editorBracketPairGuide.background6","#00000000",s.kg("editorBracketPairGuide.background6","Background color of inactive bracket pair guides (6). Requires enabling bracket pair guides.")),te=(0,r.x1A)("editorBracketPairGuide.activeBackground1","#00000000",s.kg("editorBracketPairGuide.activeBackground1","Background color of active bracket pair guides (1). Requires enabling bracket pair guides.")),ie=(0,r.x1A)("editorBracketPairGuide.activeBackground2","#00000000",s.kg("editorBracketPairGuide.activeBackground2","Background color of active bracket pair guides (2). Requires enabling bracket pair guides.")),se=(0,r.x1A)("editorBracketPairGuide.activeBackground3","#00000000",s.kg("editorBracketPairGuide.activeBackground3","Background color of active bracket pair guides (3). Requires enabling bracket pair guides.")),ne=(0,r.x1A)("editorBracketPairGuide.activeBackground4","#00000000",s.kg("editorBracketPairGuide.activeBackground4","Background color of active bracket pair guides (4). Requires enabling bracket pair guides.")),re=(0,r.x1A)("editorBracketPairGuide.activeBackground5","#00000000",s.kg("editorBracketPairGuide.activeBackground5","Background color of active bracket pair guides (5). Requires enabling bracket pair guides.")),oe=(0,r.x1A)("editorBracketPairGuide.activeBackground6","#00000000",s.kg("editorBracketPairGuide.activeBackground6","Background color of active bracket pair guides (6). Requires enabling bracket pair guides."));(0,r.x1A)("editorUnicodeHighlight.border",r.Hng,s.kg("editorUnicodeHighlight.border","Border color used to highlight unicode characters.")),(0,r.x1A)("editorUnicodeHighlight.background",r.whs,s.kg("editorUnicodeHighlight.background","Background color used to highlight unicode characters."));(0,o.zy)(((e,t)=>{const i=e.getColor(r.YtV),s=e.getColor(a),n=s&&!s.isTransparent()?s:i;n&&t.addRule(`.monaco-editor .inputarea.ime-input { background-color: ${n}; }`)}))},64454:(e,t,i)=>{"use strict";function s(e){let t=0,i=0,s=0,n=0;for(let r=0,o=e.length;rs})},93895:(e,t,i)=>{"use strict";i.d(t,{P:()=>r});var s=i(91508),n=i(1245);function r(e,t,i){let r=s.HG(e);return-1===r&&(r=e.length),function(e,t,i){let s=0;for(let o=0;o{"use strict";i.d(t,{M:()=>a,S:()=>l});var s=i(64383),n=i(74444),r=i(36677),o=i(46041);class a{static fromRangeInclusive(e){return new a(e.startLineNumber,e.endLineNumber+1)}static joinMany(e){if(0===e.length)return[];let t=new l(e[0].slice());for(let i=1;it)throw new s.D7(`startLineNumber ${e} cannot be after endLineNumberExclusive ${t}`);this.startLineNumber=e,this.endLineNumberExclusive=t}contains(e){return this.startLineNumber<=e&&et.endLineNumberExclusive>=e.startLineNumber)),i=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===i)this._normalizedRanges.splice(t,0,e);else if(t===i-1){const i=this._normalizedRanges[t];this._normalizedRanges[t]=i.join(e)}else{const s=this._normalizedRanges[t].join(this._normalizedRanges[i-1]).join(e);this._normalizedRanges.splice(t,i-t,s)}}contains(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumber<=e));return!!t&&t.endLineNumberExclusive>e}intersects(e){const t=(0,o.lx)(this._normalizedRanges,(t=>t.startLineNumbere.startLineNumber}getUnion(e){if(0===this._normalizedRanges.length)return e;if(0===e._normalizedRanges.length)return this;const t=[];let i=0,s=0,n=null;for(;i=r.startLineNumber?n=new a(n.startLineNumber,Math.max(n.endLineNumberExclusive,r.endLineNumberExclusive)):(t.push(n),n=r)}return null!==n&&t.push(n),new l(t)}subtractFrom(e){const t=(0,o.hw)(this._normalizedRanges,(t=>t.endLineNumberExclusive>=e.startLineNumber)),i=(0,o.iM)(this._normalizedRanges,(t=>t.startLineNumber<=e.endLineNumberExclusive))+1;if(t===i)return new l([e]);const s=[];let n=e.startLineNumber;for(let r=t;rn&&s.push(new a(n,e.startLineNumber)),n=e.endLineNumberExclusive}return ne.toString())).join(", ")}getIntersection(e){const t=[];let i=0,s=0;for(;it.delta(e))))}}},74444:(e,t,i)=>{"use strict";i.d(t,{L:()=>n,h:()=>r});var s=i(64383);class n{static addRange(e,t){let i=0;for(;it))return new n(e,t)}static ofLength(e){return new n(0,e)}static ofStartAndLength(e,t){return new n(e,e+t)}constructor(e,t){if(this.start=e,this.endExclusive=t,e>t)throw new s.D7(`Invalid range: ${this.toString()}`)}get isEmpty(){return this.start===this.endExclusive}delta(e){return new n(this.start+e,this.endExclusive+e)}deltaStart(e){return new n(this.start+e,this.endExclusive)}deltaEnd(e){return new n(this.start,this.endExclusive+e)}get length(){return this.endExclusive-this.start}toString(){return`[${this.start}, ${this.endExclusive})`}contains(e){return this.start<=e&&e=e.endExclusive}slice(e){return e.slice(this.start,this.endExclusive)}substring(e){return e.substring(this.start,this.endExclusive)}clip(e){if(this.isEmpty)throw new s.D7(`Invalid clipping range: ${this.toString()}`);return Math.max(this.start,Math.min(this.endExclusive-1,e))}clipCyclic(e){if(this.isEmpty)throw new s.D7(`Invalid clipping range: ${this.toString()}`);return e=this.endExclusive?this.start+(e-this.start)%this.length:e}forEach(e){for(let t=this.start;te.toString())).join(", ")}intersectsStrict(e){let t=0;for(;te+t.length),0)}}},83069:(e,t,i)=>{"use strict";i.d(t,{y:()=>s});class s{constructor(e,t){this.lineNumber=e,this.column=t}with(e=this.lineNumber,t=this.column){return e===this.lineNumber&&t===this.column?this:new s(e,t)}delta(e=0,t=0){return this.with(this.lineNumber+e,this.column+t)}equals(e){return s.equals(this,e)}static equals(e,t){return!e&&!t||!!e&&!!t&&e.lineNumber===t.lineNumber&&e.column===t.column}isBefore(e){return s.isBefore(this,e)}static isBefore(e,t){return e.lineNumber{"use strict";i.d(t,{Q:()=>n});var s=i(83069);class n{constructor(e,t,i,s){e>i||e===i&&t>s?(this.startLineNumber=i,this.startColumn=s,this.endLineNumber=e,this.endColumn=t):(this.startLineNumber=e,this.startColumn=t,this.endLineNumber=i,this.endColumn=s)}isEmpty(){return n.isEmpty(this)}static isEmpty(e){return e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn}containsPosition(e){return n.containsPosition(this,e)}static containsPosition(e,t){return!(t.lineNumbere.endLineNumber)&&(!(t.lineNumber===e.startLineNumber&&t.columne.endColumn))}static strictContainsPosition(e,t){return!(t.lineNumbere.endLineNumber)&&(!(t.lineNumber===e.startLineNumber&&t.column<=e.startColumn)&&!(t.lineNumber===e.endLineNumber&&t.column>=e.endColumn))}containsRange(e){return n.containsRange(this,e)}static containsRange(e,t){return!(t.startLineNumbere.endLineNumber||t.endLineNumber>e.endLineNumber)&&(!(t.startLineNumber===e.startLineNumber&&t.startColumne.endColumn)))}strictContainsRange(e){return n.strictContainsRange(this,e)}static strictContainsRange(e,t){return!(t.startLineNumbere.endLineNumber||t.endLineNumber>e.endLineNumber)&&(!(t.startLineNumber===e.startLineNumber&&t.startColumn<=e.startColumn)&&!(t.endLineNumber===e.endLineNumber&&t.endColumn>=e.endColumn)))}plusRange(e){return n.plusRange(this,e)}static plusRange(e,t){let i,s,r,o;return t.startLineNumbere.endLineNumber?(r=t.endLineNumber,o=t.endColumn):t.endLineNumber===e.endLineNumber?(r=t.endLineNumber,o=Math.max(t.endColumn,e.endColumn)):(r=e.endLineNumber,o=e.endColumn),new n(i,s,r,o)}intersectRanges(e){return n.intersectRanges(this,e)}static intersectRanges(e,t){let i=e.startLineNumber,s=e.startColumn,r=e.endLineNumber,o=e.endColumn;const a=t.startLineNumber,l=t.startColumn,c=t.endLineNumber,h=t.endColumn;return ic?(r=c,o=h):r===c&&(o=Math.min(o,h)),i>r||i===r&&s>o?null:new n(i,s,r,o)}equalsRange(e){return n.equalsRange(this,e)}static equalsRange(e,t){return!e&&!t||!!e&&!!t&&e.startLineNumber===t.startLineNumber&&e.startColumn===t.startColumn&&e.endLineNumber===t.endLineNumber&&e.endColumn===t.endColumn}getEndPosition(){return n.getEndPosition(this)}static getEndPosition(e){return new s.y(e.endLineNumber,e.endColumn)}getStartPosition(){return n.getStartPosition(this)}static getStartPosition(e){return new s.y(e.startLineNumber,e.startColumn)}toString(){return"["+this.startLineNumber+","+this.startColumn+" -> "+this.endLineNumber+","+this.endColumn+"]"}setEndPosition(e,t){return new n(this.startLineNumber,this.startColumn,e,t)}setStartPosition(e,t){return new n(e,t,this.endLineNumber,this.endColumn)}collapseToStart(){return n.collapseToStart(this)}static collapseToStart(e){return new n(e.startLineNumber,e.startColumn,e.startLineNumber,e.startColumn)}collapseToEnd(){return n.collapseToEnd(this)}static collapseToEnd(e){return new n(e.endLineNumber,e.endColumn,e.endLineNumber,e.endColumn)}delta(e){return new n(this.startLineNumber+e,this.startColumn,this.endLineNumber+e,this.endColumn)}static fromPositions(e,t=e){return new n(e.lineNumber,e.column,t.lineNumber,t.column)}static lift(e){return e?new n(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):null}static isIRange(e){return e&&"number"===typeof e.startLineNumber&&"number"===typeof e.startColumn&&"number"===typeof e.endLineNumber&&"number"===typeof e.endColumn}static areIntersectingOrTouching(e,t){return!(e.endLineNumbere.startLineNumber}toJSON(){return this}}},75326:(e,t,i)=>{"use strict";i.d(t,{L:()=>r});var s=i(83069),n=i(36677);class r extends n.Q{constructor(e,t,i,s){super(e,t,i,s),this.selectionStartLineNumber=e,this.selectionStartColumn=t,this.positionLineNumber=i,this.positionColumn=s}toString(){return"["+this.selectionStartLineNumber+","+this.selectionStartColumn+" -> "+this.positionLineNumber+","+this.positionColumn+"]"}equalsSelection(e){return r.selectionsEqual(this,e)}static selectionsEqual(e,t){return e.selectionStartLineNumber===t.selectionStartLineNumber&&e.selectionStartColumn===t.selectionStartColumn&&e.positionLineNumber===t.positionLineNumber&&e.positionColumn===t.positionColumn}getDirection(){return this.selectionStartLineNumber===this.startLineNumber&&this.selectionStartColumn===this.startColumn?0:1}setEndPosition(e,t){return 0===this.getDirection()?new r(this.startLineNumber,this.startColumn,e,t):new r(e,t,this.startLineNumber,this.startColumn)}getPosition(){return new s.y(this.positionLineNumber,this.positionColumn)}getSelectionStart(){return new s.y(this.selectionStartLineNumber,this.selectionStartColumn)}setStartPosition(e,t){return 0===this.getDirection()?new r(e,t,this.endLineNumber,this.endColumn):new r(this.endLineNumber,this.endColumn,e,t)}static fromPositions(e,t=e){return new r(e.lineNumber,e.column,t.lineNumber,t.column)}static fromRange(e,t){return 0===t?new r(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn):new r(e.endLineNumber,e.endColumn,e.startLineNumber,e.startColumn)}static liftSelection(e){return new r(e.selectionStartLineNumber,e.selectionStartColumn,e.positionLineNumber,e.positionColumn)}static selectionsArrEqual(e,t){if(e&&!t||!e&&t)return!1;if(!e&&!t)return!0;if(e.length!==t.length)return!1;for(let i=0,s=e.length;i{"use strict";i.d(t,{Su:()=>d,b7:()=>h,fe:()=>u});var s=i(91508),n=i(98067),r=i(81674);let o,a,l;function c(){return o||(o=new TextDecoder("UTF-16LE")),o}function h(){return l||(l=n.cm()?c():(a||(a=new TextDecoder("UTF-16BE")),a)),l}function d(e,t,i){const s=new Uint16Array(e.buffer,t,i);return i>0&&(65279===s[0]||65534===s[0])?function(e,t,i){const s=[];let n=0;for(let o=0;o=this._capacity)return this._flushBuffer(),void(this._completedStrings[this._completedStrings.length]=e);for(let i=0;i{"use strict";i.d(t,{k:()=>o,x:()=>a});var s=i(81674),n=i(99020);function r(e){return e.replace(/\n/g,"\\n").replace(/\r/g,"\\r")}class o{get oldLength(){return this.oldText.length}get oldEnd(){return this.oldPosition+this.oldText.length}get newLength(){return this.newText.length}get newEnd(){return this.newPosition+this.newText.length}constructor(e,t,i,s){this.oldPosition=e,this.oldText=t,this.newPosition=i,this.newText=s}toString(){return 0===this.oldText.length?`(insert@${this.oldPosition} "${r(this.newText)}")`:0===this.newText.length?`(delete@${this.oldPosition} "${r(this.oldText)}")`:`(replace@${this.oldPosition} "${r(this.oldText)}" with "${r(this.newText)}")`}static _writeStringSize(e){return 4+2*e.length}static _writeString(e,t,i){const n=t.length;s.Sw(e,n,i),i+=4;for(let r=0;r{"use strict";i.d(t,{CO:()=>g,WR:()=>d,mF:()=>h});var s=i(66782),n=i(64383),r=i(83069),o=i(74444),a=i(50973);class l{constructor(e){this.text=e,this.lineStartOffsetByLineIdx=[],this.lineStartOffsetByLineIdx.push(0);for(let t=0;t(0,s.Xo)(e,((e,t)=>e.range.getEndPosition().isBeforeOrEqual(t.range.getStartPosition())))))}apply(e){let t="",i=new r.y(1,1);for(const n of this.edits){const s=n.range,r=s.getStartPosition(),o=s.getEndPosition(),a=u(i,r);a.isEmpty()||(t+=e.getValueOfRange(a)),t+=n.text,i=o}const s=u(i,e.endPositionExclusive);return s.isEmpty()||(t+=e.getValueOfRange(s)),t}applyToString(e){const t=new p(e);return this.apply(t)}getNewRanges(){const e=[];let t=0,i=0,s=0;for(const n of this.edits){const o=a.W.ofText(n.text),l=r.y.lift({lineNumber:n.range.startLineNumber+i,column:n.range.startColumn+(n.range.startLineNumber===t?s:0)}),c=o.createRange(l);e.push(c),i=c.endLineNumber-n.range.endLineNumber,s=c.endColumn-n.range.endColumn,t=n.range.endLineNumber}return e}}class d{constructor(e,t){this.range=e,this.text=t}toSingleEditOperation(){return{range:this.range,text:this.text}}}function u(e,t){if(e.lineNumber===t.lineNumber&&e.column===Number.MAX_SAFE_INTEGER)return c.Q.fromPositions(t,t);if(!e.isBeforeOrEqual(t))throw new n.D7("start must be before end");return new c.Q(e.lineNumber,e.column,t.lineNumber,t.column)}class g{get endPositionExclusive(){return this.length.addToPosition(new r.y(1,1))}}class p extends g{constructor(e){super(),this.value=e,this._t=new l(this.value)}getValueOfRange(e){return this._t.getOffsetRange(e).substring(this.value)}get length(){return this._t.textLength}}},50973:(e,t,i)=>{"use strict";i.d(t,{W:()=>r});var s=i(83069),n=i(36677);class r{static{this.zero=new r(0,0)}static betweenPositions(e,t){return e.lineNumber===t.lineNumber?new r(0,t.column-e.column):new r(t.lineNumber-e.lineNumber,t.column-1)}static ofRange(e){return r.betweenPositions(e.getStartPosition(),e.getEndPosition())}static ofText(e){let t=0,i=0;for(const s of e)"\n"===s?(t++,i=0):i++;return new r(t,i)}constructor(e,t){this.lineCount=e,this.columnCount=t}isGreaterThanOrEqualTo(e){return this.lineCount!==e.lineCount?this.lineCount>e.lineCount:this.columnCount>=e.columnCount}createRange(e){return 0===this.lineCount?new n.Q(e.lineNumber,e.column,e.lineNumber,e.column+this.columnCount):new n.Q(e.lineNumber,e.column,e.lineNumber+this.lineCount,this.columnCount+1)}addToPosition(e){return 0===this.lineCount?new s.y(e.lineNumber,e.column+this.columnCount):new s.y(e.lineNumber+this.lineCount,this.columnCount+1)}toString(){return`${this.lineCount},${this.columnCount}`}}},24329:(e,t,i)=>{"use strict";i.d(t,{R:()=>s});const s={tabSize:4,indentSize:4,insertSpaces:!0,detectIndentation:!0,trimAutoWhitespace:!0,largeFileOptimizations:!0,bracketPairColorizationOptions:{enabled:!0,independentColorPoolPerBracketType:!1}}},81782:(e,t,i)=>{"use strict";i.d(t,{i:()=>a});var s=i(74320),n=i(60534);class r extends n.V{constructor(e,t){super(0),this._segmenter=null,this._cachedLine=null,this._cachedSegments=[],this.intlSegmenterLocales=t,this.intlSegmenterLocales.length>0?this._segmenter=new Intl.Segmenter(this.intlSegmenterLocales,{granularity:"word"}):this._segmenter=null;for(let i=0,s=e.length;it)break;i=s}return i}findNextIntlWordAtOrAfterOffset(e,t){for(const i of this._getIntlSegmenterWordsOnLine(e))if(!(i.index{"use strict";i.d(t,{Io:()=>a,J3:()=>r,Ld:()=>o,Th:()=>c});var s=i(42522),n=i(58925);const r="`~!@#$%^&*()-=+[{]}\\|;:'\",.<>/?";const o=function(e=""){let t="(-?\\d*\\.\\d\\w*)|([^";for(const i of r)e.indexOf(i)>=0||(t+="\\"+i);return t+="\\s]+)",new RegExp(t,"g")}();function a(e){let t=o;if(e&&e instanceof RegExp)if(e.global)t=e;else{let i="g";e.ignoreCase&&(i+="i"),e.multiline&&(i+="m"),e.unicode&&(i+="u"),t=new RegExp(e.source,i)}return t.lastIndex=0,t}const l=new n.w;function c(e,t,i,n,r){if(t=a(t),r||(r=s.f.first(l)),i.length>r.maxLen){let s=e-r.maxLen/2;return s<0?s=0:n+=s,c(e,t,i=i.substring(s,e+r.maxLen/2),n,r)}const o=Date.now(),d=e-1-n;let u=-1,g=null;for(let s=1;!(Date.now()-o>=r.timeBudget);s++){const e=d-r.windowSize*s;t.lastIndex=Math.max(0,e);const n=h(t,i,d,u);if(!n&&g)break;if(g=n,e<=0)break;u=e}if(g){const e={word:g[0],startColumn:n+1+g.index,endColumn:n+1+g.index+g[0].length};return t.lastIndex=0,e}return null}function h(e,t,i,s){let n;for(;n=e.exec(t);){const t=n.index||0;if(t<=i&&e.lastIndex>=i)return n;if(s>0&&t>s)return null}return null}l.unshift({maxLen:1e3,windowSize:15,timeBudget:150})},35817:(e,t,i)=>{"use strict";i.d(t,{s:()=>n});var s=i(1245);class n{static whitespaceVisibleColumn(e,t,i){const n=e.length;let r=0,o=-1,a=-1;for(let l=0;l{"use strict";i.d(t,{g:()=>h});var s=i(91508),n=i(15092),r=i(32799),o=i(1245),a=i(94564),l=i(36677),c=i(83069);class h{static deleteRight(e,t,i,s){const r=[];let o=3!==e;for(let c=0,h=s.length;c=d.length+1)return!1;const u=d.charAt(h.column-2),g=s.get(u);if(!g)return!1;if((0,r.vG)(u)){if("never"===i)return!1}else if("never"===t)return!1;const p=d.charAt(h.column-1);let m=!1;for(const e of g)e.open===u&&e.close===p&&(m=!0);if(!m)return!1;if("auto"===e){let e=!1;for(let t=0,i=a.length;t1){const e=t.getLineContent(n.lineNumber),r=s.HG(e),a=-1===r?e.length+1:r+1;if(n.column<=a){const e=i.visibleColumnFromColumn(t,n),s=o.A.prevIndentTabStop(e,i.indentSize),r=i.columnFromVisibleColumn(t,n.lineNumber,s);return new l.Q(n.lineNumber,r,n.lineNumber,n.column)}}return l.Q.fromPositions(h.getPositionAfterDeleteLeft(n,t),n)}static getPositionAfterDeleteLeft(e,t){if(e.column>1){const i=s.Wd(e.column-1,t.getLineContent(e.lineNumber));return e.with(void 0,i+1)}if(e.lineNumber>1){const i=e.lineNumber-1;return new c.y(i,t.getLineMaxColumn(i))}return e}static cut(e,t,i){const s=[];let o=null;i.sort(((e,t)=>c.y.compare(e.getStartPosition(),t.getEndPosition())));for(let r=0,a=i.length;r1&&o?.endLineNumber!==e.lineNumber?(i=e.lineNumber-1,c=t.getLineMaxColumn(e.lineNumber-1),h=e.lineNumber,d=t.getLineMaxColumn(e.lineNumber)):(i=e.lineNumber,c=1,h=e.lineNumber,d=t.getLineMaxColumn(e.lineNumber));const u=new l.Q(i,c,h,d);o=u,u.isEmpty()?s[r]=null:s[r]=new n.iu(u,"")}else s[r]=null;else s[r]=new n.iu(a,"")}return new r.vY(0,s,{shouldPushStackElementBefore:!0,shouldPushStackElementAfter:!0})}}},50672:(e,t,i)=>{"use strict";i.d(t,{S:()=>s,c:()=>h});var s,n=i(631),r=i(32799),o=i(94564),a=i(97681),l=i(83069),c=i(36677);class h{static addCursorDown(e,t,i){const s=[];let n=0;for(let a=0,l=t.length;at&&(i=t,s=e.model.getLineMaxColumn(i)),r.MF.fromModelState(new r.mG(new c.Q(o.lineNumber,1,i,s),2,0,new l.y(i,s),0))}const h=t.modelState.selectionStart.getStartPosition().lineNumber;if(o.lineNumberh){const i=e.getLineCount();let s=a.lineNumber+1,n=1;return s>i&&(s=i,n=e.getLineMaxColumn(s)),r.MF.fromViewState(t.viewState.move(!0,s,n,0))}{const e=t.modelState.selectionStart.getEndPosition();return r.MF.fromModelState(t.modelState.move(!0,e.lineNumber,e.column,0))}}static word(e,t,i,s){const n=e.model.validatePosition(s);return r.MF.fromModelState(a.z.word(e.cursorConfig,e.model,t.modelState,i,n))}static cancelSelection(e,t){if(!t.modelState.hasSelection())return new r.MF(t.modelState,t.viewState);const i=t.viewState.position.lineNumber,s=t.viewState.position.column;return r.MF.fromViewState(new r.mG(new c.Q(i,s,i,s),0,0,new l.y(i,s),0))}static moveTo(e,t,i,s,n){if(i){if(1===t.modelState.selectionStartKind)return this.word(e,t,i,s);if(2===t.modelState.selectionStartKind)return this.line(e,t,i,s,n)}const o=e.model.validatePosition(s),a=n?e.coordinatesConverter.validateViewPosition(new l.y(n.lineNumber,n.column),o):e.coordinatesConverter.convertModelPositionToViewPosition(o);return r.MF.fromViewState(t.viewState.move(i,a.lineNumber,a.column,0))}static simpleMove(e,t,i,s,n,a){switch(i){case 0:return 4===a?this._moveHalfLineLeft(e,t,s):this._moveLeft(e,t,s,n);case 1:return 4===a?this._moveHalfLineRight(e,t,s):this._moveRight(e,t,s,n);case 2:return 2===a?this._moveUpByViewLines(e,t,s,n):this._moveUpByModelLines(e,t,s,n);case 3:return 2===a?this._moveDownByViewLines(e,t,s,n):this._moveDownByModelLines(e,t,s,n);case 4:return 2===a?t.map((t=>r.MF.fromViewState(o.I.moveToPrevBlankLine(e.cursorConfig,e,t.viewState,s)))):t.map((t=>r.MF.fromModelState(o.I.moveToPrevBlankLine(e.cursorConfig,e.model,t.modelState,s))));case 5:return 2===a?t.map((t=>r.MF.fromViewState(o.I.moveToNextBlankLine(e.cursorConfig,e,t.viewState,s)))):t.map((t=>r.MF.fromModelState(o.I.moveToNextBlankLine(e.cursorConfig,e.model,t.modelState,s))));case 6:return this._moveToViewMinColumn(e,t,s);case 7:return this._moveToViewFirstNonWhitespaceColumn(e,t,s);case 8:return this._moveToViewCenterColumn(e,t,s);case 9:return this._moveToViewMaxColumn(e,t,s);case 10:return this._moveToViewLastNonWhitespaceColumn(e,t,s);default:return null}}static viewportMove(e,t,i,s,n){const r=e.getCompletelyVisibleViewRange(),o=e.coordinatesConverter.convertViewRangeToModelRange(r);switch(i){case 11:{const i=this._firstLineNumberInRange(e.model,o,n),r=e.model.getLineFirstNonWhitespaceColumn(i);return[this._moveToModelPosition(e,t[0],s,i,r)]}case 13:{const i=this._lastLineNumberInRange(e.model,o,n),r=e.model.getLineFirstNonWhitespaceColumn(i);return[this._moveToModelPosition(e,t[0],s,i,r)]}case 12:{const i=Math.round((o.startLineNumber+o.endLineNumber)/2),n=e.model.getLineFirstNonWhitespaceColumn(i);return[this._moveToModelPosition(e,t[0],s,i,n)]}case 14:{const i=[];for(let n=0,o=t.length;ni.endLineNumber-1?i.endLineNumber-1:nr.MF.fromViewState(o.I.moveLeft(e.cursorConfig,e,t.viewState,i,s))))}static _moveHalfLineLeft(e,t,i){const s=[];for(let n=0,a=t.length;nr.MF.fromViewState(o.I.moveRight(e.cursorConfig,e,t.viewState,i,s))))}static _moveHalfLineRight(e,t,i){const s=[];for(let n=0,a=t.length;n{"use strict";i.d(t,{I:()=>h});var s=i(91508),n=i(1245),r=i(83069),o=i(36677),a=i(35817),l=i(32799);class c{constructor(e,t,i){this._cursorPositionBrand=void 0,this.lineNumber=e,this.column=t,this.leftoverVisibleColumns=i}}class h{static leftPosition(e,t){if(t.column>e.getLineMinColumn(t.lineNumber))return t.delta(void 0,-s.MV(e.getLineContent(t.lineNumber),t.column-1));if(t.lineNumber>1){const i=t.lineNumber-1;return new r.y(i,e.getLineMaxColumn(i))}return t}static leftPositionAtomicSoftTabs(e,t,i){if(t.column<=e.getLineIndentColumn(t.lineNumber)){const s=e.getLineMinColumn(t.lineNumber),n=e.getLineContent(t.lineNumber),o=a.s.atomicPosition(n,t.column-1,i,0);if(-1!==o&&o+1>=s)return new r.y(t.lineNumber,o+1)}return this.leftPosition(e,t)}static left(e,t,i){const s=e.stickyTabStops?h.leftPositionAtomicSoftTabs(t,i,e.tabSize):h.leftPosition(t,i);return new c(s.lineNumber,s.column,0)}static moveLeft(e,t,i,s,n){let r,o;if(i.hasSelection()&&!s)r=i.selection.startLineNumber,o=i.selection.startColumn;else{const s=i.position.delta(void 0,-(n-1)),a=t.normalizePosition(h.clipPositionColumn(s,t),0),l=h.left(e,t,a);r=l.lineNumber,o=l.column}return i.move(s,r,o,0)}static clipPositionColumn(e,t){return new r.y(e.lineNumber,h.clipRange(e.column,t.getLineMinColumn(e.lineNumber),t.getLineMaxColumn(e.lineNumber)))}static clipRange(e,t,i){return ei?i:e}static rightPosition(e,t,i){return iu?(i=u,s=l?t.getLineMaxColumn(i):Math.min(t.getLineMaxColumn(i),s)):s=e.columnFromVisibleColumn(t,i,d),o=m?0:d-n.A.visibleColumnFromColumn(t.getLineContent(i),s,e.tabSize),void 0!==h){const e=new r.y(i,s),n=t.normalizePosition(e,h);o+=s-n.column,i=n.lineNumber,s=n.column}return new c(i,s,o)}static down(e,t,i,s,n,r,o){return this.vertical(e,t,i,s,n,i+r,o,4)}static moveDown(e,t,i,s,n){let o,a;i.hasSelection()&&!s?(o=i.selection.endLineNumber,a=i.selection.endColumn):(o=i.position.lineNumber,a=i.position.column);let l,c=0;do{l=h.down(e,t,o+c,a,i.leftoverVisibleColumns,n,!0);if(t.normalizePosition(new r.y(l.lineNumber,l.column),2).lineNumber>o)break}while(c++<10&&o+c1&&this._isBlankLine(t,n);)n--;for(;n>1&&!this._isBlankLine(t,n);)n--;return i.move(s,n,t.getLineMinColumn(n),0)}static moveToNextBlankLine(e,t,i,s){const n=t.getLineCount();let r=i.position.lineNumber;for(;r{"use strict";i.d(t,{AO:()=>w,Dr:()=>L,Hs:()=>k,K4:()=>C,Ls:()=>y,UN:()=>T,YA:()=>R,dU:()=>_,ey:()=>B,h0:()=>x,is:()=>E,kr:()=>S,oi:()=>b,sx:()=>v});var s=i(64383),n=i(91508),r=i(15092),o=i(7936),a=i(71964),l=i(32799),c=i(81782),h=i(36677),d=i(83069),u=i(38566),g=i(17469),p=i(12296),m=i(82365),f=i(63346);class _{static getEdits(e,t,i,s,n){if(!n&&this._isAutoIndentType(e,t,i)){const n=[];for(const o of i){const i=this._findActualIndentationForSelection(e,t,o,s);if(null===i)return;n.push({selection:o,indentation:i})}const r=b.getAutoClosingPairClose(e,t,i,s,!1);return this._getIndentationAndAutoClosingPairEdits(e,t,n,s,r)}}static _isAutoIndentType(e,t,i){if(e.autoIndent<4)return!1;for(let s=0,n=i.length;sU(e,t),unshiftIndent:t=>H(e,t)},e.languageConfigurationService);if(null===n)return null;const r=(0,g.Cw)(t,i.startLineNumber,i.startColumn);return n===e.normalizeIndentation(r)?null:n}static _getIndentationAndAutoClosingPairEdits(e,t,i,s,n){const r=i.map((({selection:i,indentation:r})=>{if(null!==n){const o=this._getEditFromIndentationAndSelection(e,t,r,i,s,!1);return new N(o,i,s,n)}{const n=this._getEditFromIndentationAndSelection(e,t,r,i,s,!0);return F(n.range,n.text,!1)}}));return new l.vY(4,r,{shouldPushStackElementBefore:!0,shouldPushStackElementAfter:!1})}static _getEditFromIndentationAndSelection(e,t,i,s,n,r=!0){const o=s.startLineNumber,a=t.getLineFirstNonWhitespaceColumn(o);let l=e.normalizeIndentation(i);if(0!==a){l+=t.getLineContent(o).substring(a-1,s.startColumn-1)}l+=r?n:"";return{range:new h.Q(o,1,s.endLineNumber,s.endColumn),text:l}}}class v{static getEdits(e,t,i,s,n,r){if(P(t,i,s,n,r))return this._runAutoClosingOvertype(e,s,r)}static _runAutoClosingOvertype(e,t,i){const s=[];for(let n=0,o=t.length;nnew r.iu(new h.Q(e.positionLineNumber,e.positionColumn,e.positionLineNumber,e.positionColumn+1),"",!1)));return new l.vY(4,e,{shouldPushStackElementBefore:!0,shouldPushStackElementAfter:!1})}}}class b{static getEdits(e,t,i,s,n,r){if(!r){const r=this.getAutoClosingPairClose(e,t,i,s,n);if(null!==r)return this._runAutoClosingOpenCharType(i,s,n,r)}}static _runAutoClosingOpenCharType(e,t,i,s){const n=[];for(let r=0,o=e.length;r{const t=e.getPosition();return n?{lineNumber:t.lineNumber,beforeColumn:t.column-s.length,afterColumn:t.column}:{lineNumber:t.lineNumber,beforeColumn:t.column,afterColumn:t.column}})),o=this._findAutoClosingPairOpen(e,t,r.map((e=>new d.y(e.lineNumber,e.beforeColumn))),s);if(!o)return null;let a,h;if((0,l.vG)(s))a=e.autoClosingQuotes,h=e.shouldAutoCloseBefore.quote;else{!!e.blockCommentStartToken&&o.open.includes(e.blockCommentStartToken)?(a=e.autoClosingComments,h=e.shouldAutoCloseBefore.comment):(a=e.autoClosingBrackets,h=e.shouldAutoCloseBefore.bracket)}if("never"===a)return null;const u=this._findContainedAutoClosingPair(e,o),g=u?u.close:"";let m=!0;for(const l of r){const{lineNumber:i,beforeColumn:n,afterColumn:r}=l,d=t.getLineContent(i),u=d.substring(0,n-1),f=d.substring(r-1);if(f.startsWith(g)||(m=!1),f.length>0){const t=f.charAt(0);if(!this._isBeforeClosingBrace(e,f)&&!h(t))return null}if(1===o.open.length&&("'"===s||'"'===s)&&"always"!==a){const t=(0,c.i)(e.wordSeparators,[]);if(u.length>0){const e=u.charCodeAt(u.length-1);if(0===t.get(e))return null}}if(!t.tokenization.isCheapToTokenize(i))return null;t.tokenization.forceTokenization(i);const _=t.tokenization.getLineTokens(i),v=(0,p.BQ)(_,n-1);if(!o.shouldAutoClose(v,n-v.firstCharOffset))return null;const C=o.findNeutralCharacter();if(C){const e=t.tokenization.getTokenTypeIfInsertingCharacter(i,n,C);if(!o.isOK(e))return null}}return m?o.close.substring(0,o.close.length-g.length):o.close}static _findContainedAutoClosingPair(e,t){if(t.open.length<=1)return null;const i=t.close.charAt(t.close.length-1),s=e.autoClosingPairs.autoClosingPairsCloseByEnd.get(i)||[];let n=null;for(const r of s)r.open!==t.open&&t.open.includes(r.open)&&t.close.endsWith(r.close)&&(!n||r.open.length>n.open.length)&&(n=r);return n}static _findAutoClosingPairOpen(e,t,i,s){const n=e.autoClosingPairs.autoClosingPairsOpenByEnd.get(s);if(!n)return null;let r=null;for(const o of n)if(null===r||o.open.length>r.open.length){let e=!0;for(const n of i){if(t.getValueInRange(new h.Q(n.lineNumber,n.column-o.open.length+1,n.lineNumber,n.column))+s!==o.open){e=!1;break}}e&&(r=o)}return r}static _isBeforeClosingBrace(e,t){const i=t.charAt(0),s=e.autoClosingPairs.autoClosingPairsOpenByStart.get(i)||[],n=e.autoClosingPairs.autoClosingPairsCloseByStart.get(i)||[],r=s.some((e=>t.startsWith(e.open))),o=n.some((e=>t.startsWith(e.close)));return!r&&o}}class E{static getEdits(e,t,i,s,n){if(!n&&this._isSurroundSelectionType(e,t,i,s))return this._runSurroundSelectionType(e,i,s)}static _runSurroundSelectionType(e,t,i){const s=[];for(let n=0,r=t.length;n=4){const o=(0,m.MU)(e.autoIndent,t,s,{unshiftIndent:t=>H(e,t),shiftIndent:t=>U(e,t),normalizeIndentation:t=>e.normalizeIndentation(t)},e.languageConfigurationService);if(o){let a=e.visibleColumnFromColumn(t,s.getEndPosition());const l=s.endColumn,c=t.getLineContent(s.endLineNumber),h=n.HG(c);if(s=h>=0?s.setEndPosition(s.endLineNumber,Math.max(s.endColumn,h+1)):s.setEndPosition(s.endLineNumber,t.getLineMaxColumn(s.endLineNumber)),i)return new r.q2(s,"\n"+e.normalizeIndentation(o.afterEnter),!0);{let t=0;return l<=h+1&&(e.insertSpaces||(a=Math.ceil(a/e.indentSize)),t=Math.min(a+1-e.normalizeIndentation(o.afterEnter).length-1,0)),new r.iP(s,"\n"+e.normalizeIndentation(o.afterEnter),0,t,!0)}}}return F(s,"\n"+e.normalizeIndentation(l),i)}static lineInsertBefore(e,t,i){if(null===t||null===i)return[];const s=[];for(let n=0,o=i.length;nthis._compositionType(i,e,n,r,o,a)));return new l.vY(4,c,{shouldPushStackElementBefore:O(e,4),shouldPushStackElementAfter:!1})}static _compositionType(e,t,i,s,n,o){if(!t.isEmpty())return null;const a=t.getPosition(),l=Math.max(1,a.column-s),c=Math.min(e.getLineMaxColumn(a.lineNumber),a.column+n),d=new h.Q(a.lineNumber,l,a.lineNumber,c);return e.getValueInRange(d)===i&&0===o?null:new r.iP(d,i,0,o)}}class T{static getEdits(e,t,i){const s=[];for(let o=0,a=t.length;o1){let s;for(s=i-1;s>=1;s--){const e=t.getLineContent(s);if(n.lT(e)>=0)break}if(s<1)return null;const o=t.getLineMaxColumn(s),a=(0,f.h)(e.autoIndent,t,new h.Q(s,o,s,o),e.languageConfigurationService);a&&(r=a.indentation+a.appendText)}return s&&(s===u.l.Indent&&(r=U(e,r)),s===u.l.Outdent&&(r=H(e,r)),r=e.normalizeIndentation(r)),r||null}static _replaceJumpToNextIndent(e,t,i,s){let n="";const o=i.getStartPosition();if(e.insertSpaces){const i=e.visibleColumnFromColumn(t,o),s=e.indentSize,r=s-i%s;for(let e=0;e2?c.charCodeAt(a.column-2):0)&&h)return!1;if("auto"===e.autoClosingOvertype){let e=!1;for(let t=0,i=s.length;t{"use strict";i.d(t,{T:()=>a,v:()=>l});var s=i(7936),n=i(71964),r=i(32799),o=i(26685);class a{static indent(e,t,i){if(null===t||null===i)return[];const n=[];for(let r=0,o=i.length;r{"use strict";i.d(t,{c:()=>h,z:()=>c});var s=i(91508),n=i(32799),r=i(1226),o=i(81782),a=i(83069),l=i(36677);class c{static _createWord(e,t,i,s,n){return{start:s,end:n,wordType:t,nextCharClass:i}}static _createIntlWord(e,t){return{start:e.index,end:e.index+e.segment.length,wordType:1,nextCharClass:t}}static _findPreviousWordOnLine(e,t,i){const s=t.getLineContent(i.lineNumber);return this._doFindPreviousWordOnLine(s,e,i)}static _doFindPreviousWordOnLine(e,t,i){let s=0;const n=t.findPrevIntlWordBeforeOrAtOffset(e,i.column-2);for(let r=i.column-2;r>=0;r--){const i=e.charCodeAt(r),o=t.get(i);if(n&&r===n.index)return this._createIntlWord(n,o);if(0===o){if(2===s)return this._createWord(e,s,o,r+1,this._findEndOfWord(e,t,s,r+1));s=1}else if(2===o){if(1===s)return this._createWord(e,s,o,r+1,this._findEndOfWord(e,t,s,r+1));s=2}else if(1===o&&0!==s)return this._createWord(e,s,o,r+1,this._findEndOfWord(e,t,s,r+1))}return 0!==s?this._createWord(e,s,1,0,this._findEndOfWord(e,t,s,0)):null}static _findEndOfWord(e,t,i,s){const n=t.findNextIntlWordAtOrAfterOffset(e,s),r=e.length;for(let o=s;o=0;r--){const s=e.charCodeAt(r),o=t.get(s);if(n&&r===n.index)return r;if(1===o)return r+1;if(1===i&&2===o)return r+1;if(2===i&&0===o)return r+1}return 0}static moveWordLeft(e,t,i,s,n){let r=i.lineNumber,o=i.column;1===o&&r>1&&(r-=1,o=t.getLineMaxColumn(r));let l=c._findPreviousWordOnLine(e,t,new a.y(r,o));if(0===s)return new a.y(r,l?l.start+1:1);if(1===s)return!n&&l&&2===l.wordType&&l.end-l.start===1&&0===l.nextCharClass&&(l=c._findPreviousWordOnLine(e,t,new a.y(r,l.start+1))),new a.y(r,l?l.start+1:1);if(3===s){for(;l&&2===l.wordType;)l=c._findPreviousWordOnLine(e,t,new a.y(r,l.start+1));return new a.y(r,l?l.start+1:1)}return l&&o<=l.end+1&&(l=c._findPreviousWordOnLine(e,t,new a.y(r,l.start+1))),new a.y(r,l?l.end+1:1)}static _moveWordPartLeft(e,t){const i=t.lineNumber,n=e.getLineMaxColumn(i);if(1===t.column)return i>1?new a.y(i-1,e.getLineMaxColumn(i-1)):t;const r=e.getLineContent(i);for(let o=t.column-1;o>1;o--){const e=r.charCodeAt(o-2),t=r.charCodeAt(o-1);if(95===e&&95!==t)return new a.y(i,o);if(45===e&&45!==t)return new a.y(i,o);if((s.Lv(e)||s.DB(e))&&s.Wv(t))return new a.y(i,o);if(s.Wv(e)&&s.Wv(t)&&o+1=l.start+1&&(l=c._findNextWordOnLine(e,t,new a.y(n,l.end+1))),r=l?l.start+1:t.getLineMaxColumn(n);return new a.y(n,r)}static _moveWordPartRight(e,t){const i=t.lineNumber,n=e.getLineMaxColumn(i);if(t.column===n)return i1?u=1:(d--,u=s.getLineMaxColumn(d)):(g&&u<=g.end+1&&(g=c._findPreviousWordOnLine(i,s,new a.y(d,g.start+1))),g?u=g.end+1:u>1?u=1:(d--,u=s.getLineMaxColumn(d))),new l.Q(d,u,h.lineNumber,h.column)}static deleteInsideWord(e,t,i){if(!i.isEmpty())return i;const s=new a.y(i.positionLineNumber,i.positionColumn),n=this._deleteInsideWordWhitespace(t,s);return n||this._deleteInsideWordDetermineDeleteRange(e,t,s)}static _charAtIsWhitespace(e,t){const i=e.charCodeAt(t);return 32===i||9===i}static _deleteInsideWordWhitespace(e,t){const i=e.getLineContent(t.lineNumber),s=i.length;if(0===s)return null;let n=Math.max(t.column-2,0);if(!this._charAtIsWhitespace(i,n))return null;let r=Math.min(t.column-1,s-1);if(!this._charAtIsWhitespace(i,r))return null;for(;n>0&&this._charAtIsWhitespace(i,n-1);)n--;for(;r+11?new l.Q(i.lineNumber-1,t.getLineMaxColumn(i.lineNumber-1),i.lineNumber,1):i.lineNumbere.start+1<=i.column&&i.column<=e.end+1,o=(e,t)=>(e=Math.min(e,i.column),t=Math.max(t,i.column),new l.Q(i.lineNumber,e,i.lineNumber,t)),a=e=>{let t=e.start+1,i=e.end+1,r=!1;for(;i-11&&this._charAtIsWhitespace(s,t-2);)t--;return o(t,i)},h=c._findPreviousWordOnLine(e,t,i);if(h&&r(h))return a(h);const d=c._findNextWordOnLine(e,t,i);return d&&r(d)?a(d):h&&d?o(h.end+1,d.start+1):h?o(h.start+1,h.end+1):d?o(d.start+1,d.end+1):o(1,n+1)}static _deleteWordPartLeft(e,t){if(!t.isEmpty())return t;const i=t.getPosition(),s=c._moveWordPartLeft(e,i);return new l.Q(i.lineNumber,i.column,s.lineNumber,s.column)}static _findFirstNonWhitespaceChar(e,t){const i=e.length;for(let s=t;s=p.start+1&&(p=c._findNextWordOnLine(i,s,new a.y(h,p.end+1))),p?d=p.start+1:dBoolean(e)))}},32799:(e,t,i)=>{"use strict";i.d(t,{MF:()=>g,d$:()=>u,mG:()=>f,vG:()=>v,vY:()=>_});var s=i(83069),n=i(36677),r=i(75326),o=i(12296),a=i(1245),l=i(93895);const c=()=>!0,h=()=>!1,d=e=>" "===e||"\t"===e;class u{static shouldRecreate(e){return e.hasChanged(146)||e.hasChanged(132)||e.hasChanged(37)||e.hasChanged(77)||e.hasChanged(79)||e.hasChanged(80)||e.hasChanged(6)||e.hasChanged(7)||e.hasChanged(11)||e.hasChanged(9)||e.hasChanged(10)||e.hasChanged(14)||e.hasChanged(129)||e.hasChanged(50)||e.hasChanged(92)||e.hasChanged(131)}constructor(e,t,i,s){this.languageConfigurationService=s,this._cursorMoveConfigurationBrand=void 0,this._languageId=e;const n=i.options,r=n.get(146),o=n.get(50);this.readOnly=n.get(92),this.tabSize=t.tabSize,this.indentSize=t.indentSize,this.insertSpaces=t.insertSpaces,this.stickyTabStops=n.get(117),this.lineHeight=o.lineHeight,this.typicalHalfwidthCharacterWidth=o.typicalHalfwidthCharacterWidth,this.pageSize=Math.max(1,Math.floor(r.height/this.lineHeight)-2),this.useTabStops=n.get(129),this.wordSeparators=n.get(132),this.emptySelectionClipboard=n.get(37),this.copyWithSyntaxHighlighting=n.get(25),this.multiCursorMergeOverlapping=n.get(77),this.multiCursorPaste=n.get(79),this.multiCursorLimit=n.get(80),this.autoClosingBrackets=n.get(6),this.autoClosingComments=n.get(7),this.autoClosingQuotes=n.get(11),this.autoClosingDelete=n.get(9),this.autoClosingOvertype=n.get(10),this.autoSurround=n.get(14),this.autoIndent=n.get(12),this.wordSegmenterLocales=n.get(131),this.surroundingPairs={},this._electricChars=null,this.shouldAutoCloseBefore={quote:this._getShouldAutoClose(e,this.autoClosingQuotes,!0),comment:this._getShouldAutoClose(e,this.autoClosingComments,!1),bracket:this._getShouldAutoClose(e,this.autoClosingBrackets,!1)},this.autoClosingPairs=this.languageConfigurationService.getLanguageConfiguration(e).getAutoClosingPairs();const a=this.languageConfigurationService.getLanguageConfiguration(e).getSurroundingPairs();if(a)for(const c of a)this.surroundingPairs[c.open]=c.close;const l=this.languageConfigurationService.getLanguageConfiguration(e).comments;this.blockCommentStartToken=l?.blockCommentStartToken??null}get electricChars(){if(!this._electricChars){this._electricChars={};const e=this.languageConfigurationService.getLanguageConfiguration(this._languageId).electricCharacter?.getElectricCharacters();if(e)for(const t of e)this._electricChars[t]=!0}return this._electricChars}onElectricCharacter(e,t,i){const s=(0,o.BQ)(t,i-1),n=this.languageConfigurationService.getLanguageConfiguration(s.languageId).electricCharacter;return n?n.onElectricCharacter(e,s,i-s.firstCharOffset):null}normalizeIndentation(e){return(0,l.P)(e,this.indentSize,this.insertSpaces)}_getShouldAutoClose(e,t,i){switch(t){case"beforeWhitespace":return d;case"languageDefined":return this._getLanguageDefinedShouldAutoClose(e,i);case"always":return c;case"never":return h}}_getLanguageDefinedShouldAutoClose(e,t){const i=this.languageConfigurationService.getLanguageConfiguration(e).getAutoCloseBeforeSet(t);return e=>-1!==i.indexOf(e)}visibleColumnFromColumn(e,t){return a.A.visibleColumnFromColumn(e.getLineContent(t.lineNumber),t.column,this.tabSize)}columnFromVisibleColumn(e,t,i){const s=a.A.columnFromVisibleColumn(e.getLineContent(t),i,this.tabSize),n=e.getLineMinColumn(t);if(sr?r:s}}class g{static fromModelState(e){return new p(e)}static fromViewState(e){return new m(e)}static fromModelSelection(e){const t=r.L.liftSelection(e),i=new f(n.Q.fromPositions(t.getSelectionStart()),0,0,t.getPosition(),0);return g.fromModelState(i)}static fromModelSelections(e){const t=[];for(let i=0,s=e.length;i{"use strict";i.d(t,{$8:()=>a,SL:()=>o,_3:()=>l,aY:()=>h,uY:()=>c});var s=i(25890),n=i(64383),r=i(74444);class o{static trivial(e,t){return new o([new a(r.L.ofLength(e.length),r.L.ofLength(t.length))],!1)}static trivialTimedOut(e,t){return new o([new a(r.L.ofLength(e.length),r.L.ofLength(t.length))],!0)}constructor(e,t){this.diffs=e,this.hitTimeout=t}}class a{static invert(e,t){const i=[];return(0,s.pN)(e,((e,s)=>{i.push(a.fromOffsetPairs(e?e.getEndExclusives():l.zero,s?s.getStarts():new l(t,(e?e.seq2Range.endExclusive-e.seq1Range.endExclusive:0)+t)))})),i}static fromOffsetPairs(e,t){return new a(new r.L(e.offset1,t.offset1),new r.L(e.offset2,t.offset2))}static assertSorted(e){let t;for(const i of e){if(t&&!(t.seq1Range.endExclusive<=i.seq1Range.start&&t.seq2Range.endExclusive<=i.seq2Range.start))throw new n.D7("Sequence diffs must be sorted");t=i}}constructor(e,t){this.seq1Range=e,this.seq2Range=t}swap(){return new a(this.seq2Range,this.seq1Range)}toString(){return`${this.seq1Range} <-> ${this.seq2Range}`}join(e){return new a(this.seq1Range.join(e.seq1Range),this.seq2Range.join(e.seq2Range))}delta(e){return 0===e?this:new a(this.seq1Range.delta(e),this.seq2Range.delta(e))}deltaStart(e){return 0===e?this:new a(this.seq1Range.deltaStart(e),this.seq2Range.deltaStart(e))}deltaEnd(e){return 0===e?this:new a(this.seq1Range.deltaEnd(e),this.seq2Range.deltaEnd(e))}intersect(e){const t=this.seq1Range.intersect(e.seq1Range),i=this.seq2Range.intersect(e.seq2Range);if(t&&i)return new a(t,i)}getStarts(){return new l(this.seq1Range.start,this.seq2Range.start)}getEndExclusives(){return new l(this.seq1Range.endExclusive,this.seq2Range.endExclusive)}}class l{static{this.zero=new l(0,0)}static{this.max=new l(Number.MAX_SAFE_INTEGER,Number.MAX_SAFE_INTEGER)}constructor(e,t){this.offset1=e,this.offset2=t}toString(){return`${this.offset1} <-> ${this.offset2}`}delta(e){return 0===e?this:new l(this.offset1+e,this.offset2+e)}equals(e){return this.offset1===e.offset1&&this.offset2===e.offset2}}class c{static{this.instance=new c}isValid(){return!0}}class h{constructor(e){if(this.timeout=e,this.startTime=Date.now(),this.valid=!0,e<=0)throw new n.D7("timeout must be positive")}isValid(){return!(Date.now()-this.startTime{"use strict";i.d(t,{D8:()=>I});var s=i(25890),n=i(66782),r=i(86571),o=i(74444),a=i(36677),l=i(68938);class c{constructor(e,t){this.width=e,this.height=t,this.array=[],this.array=new Array(e*t)}get(e,t){return this.array[e+t*this.width]}set(e,t,i){this.array[e+t*this.width]=i}}function h(e){return 32===e||9===e}class d{static{this.chrKeys=new Map}static getKey(e){let t=this.chrKeys.get(e);return void 0===t&&(t=this.chrKeys.size,this.chrKeys.set(e,t)),t}constructor(e,t,i){this.range=e,this.lines=t,this.source=i,this.histogram=[];let s=0;for(let n=e.startLineNumber-1;n0&&c>0&&3===r.get(o-1,c-1)&&(u+=a.get(o-1,c-1)),u+=s?s(o,c):1):u=-1;const g=Math.max(h,d,u);if(g===u){const e=o>0&&c>0?a.get(o-1,c-1):0;a.set(o,c,e+1),r.set(o,c,3)}else g===h?(a.set(o,c,0),r.set(o,c,1)):g===d&&(a.set(o,c,0),r.set(o,c,2));n.set(o,c,g)}const h=[];let d=e.length,u=t.length;function g(e,t){e+1===d&&t+1===u||h.push(new l.$8(new o.L(e+1,d),new o.L(t+1,u))),d=e,u=t}let p=e.length-1,m=t.length-1;for(;p>=0&&m>=0;)3===r.get(p,m)?(g(p,m),p--,m--):1===r.get(p,m)?p--:m--;return g(-1,-1),h.reverse(),new l.SL(h,!1)}}class g{compute(e,t,i=l.uY.instance){if(0===e.length||0===t.length)return l.SL.trivial(e,t);const s=e,n=t;function r(e,t){for(;es.length||u>n.length)continue;const g=r(l,u);c.set(d,g);const m=l===o?h.get(d+1):h.get(d-1);if(h.set(d,g!==l?new p(m,l,u,g-l):m),c.get(d)===s.length&&c.get(d)-d===n.length)break e}}let u=h.get(d);const g=[];let _=s.length,v=n.length;for(;;){const e=u?u.x+u.length:0,t=u?u.y+u.length:0;if(e===_&&t===v||g.push(new l.$8(new o.L(e,_),new o.L(t,v))),!u)break;_=u.x,v=u.y,u=u.prev}return g.reverse(),new l.SL(g,!1)}}class p{constructor(e,t,i,s){this.prev=e,this.x=t,this.y=i,this.length=s}}class m{constructor(){this.positiveArr=new Int32Array(10),this.negativeArr=new Int32Array(10)}get(e){return e<0?(e=-e-1,this.negativeArr[e]):this.positiveArr[e]}set(e,t){if(e<0){if((e=-e-1)>=this.negativeArr.length){const e=this.negativeArr;this.negativeArr=new Int32Array(2*e.length),this.negativeArr.set(e)}this.negativeArr[e]=t}else{if(e>=this.positiveArr.length){const e=this.positiveArr;this.positiveArr=new Int32Array(2*e.length),this.positiveArr.set(e)}this.positiveArr[e]=t}}}class f{constructor(){this.positiveArr=[],this.negativeArr=[]}get(e){return e<0?(e=-e-1,this.negativeArr[e]):this.positiveArr[e]}set(e,t){e<0?(e=-e-1,this.negativeArr[e]=t):this.positiveArr[e]=t}}var _=i(87723),v=i(46041),C=i(74320),b=i(83069);class E{constructor(e,t,i){this.lines=e,this.range=t,this.considerWhitespaceChanges=i,this.elements=[],this.firstElementOffsetByLineIdx=[],this.lineStartOffsets=[],this.trimmedWsLengthsByLineIdx=[],this.firstElementOffsetByLineIdx.push(0);for(let s=this.range.startLineNumber;s<=this.range.endLineNumber;s++){let t=e[s-1],n=0;s===this.range.startLineNumber&&this.range.startColumn>1&&(n=this.range.startColumn-1,t=t.substring(n)),this.lineStartOffsets.push(n);let r=0;if(!i){const e=t.trimStart();r=t.length-e.length,t=e.trimEnd()}this.trimmedWsLengthsByLineIdx.push(r);const o=s===this.range.endLineNumber?Math.min(this.range.endColumn-1-n-r,t.length):t.length;for(let e=0;eString.fromCharCode(e))).join("")}getElement(e){return this.elements[e]}get length(){return this.elements.length}getBoundaryScore(e){const t=L(e>0?this.elements[e-1]:-1),i=L(et<=e)),s=e-this.firstElementOffsetByLineIdx[i];return new b.y(this.range.startLineNumber+i,1+this.lineStartOffsets[i]+s+(0===s&&"left"===t?0:this.trimmedWsLengthsByLineIdx[i]))}translateRange(e){const t=this.translateOffset(e.start,"right"),i=this.translateOffset(e.endExclusive,"left");return i.isBefore(t)?a.Q.fromPositions(i,i):a.Q.fromPositions(t,i)}findWordContaining(e){if(e<0||e>=this.elements.length)return;if(!S(this.elements[e]))return;let t=e;for(;t>0&&S(this.elements[t-1]);)t--;let i=e;for(;it<=e.start))??0,i=(0,v.XP)(this.firstElementOffsetByLineIdx,(t=>e.endExclusive<=t))??this.elements.length;return new o.L(t,i)}}function S(e){return e>=97&&e<=122||e>=65&&e<=90||e>=48&&e<=57}const y={0:0,1:0,2:0,3:10,4:2,5:30,6:3,7:10,8:10};function w(e){return y[e]}function L(e){return 10===e?8:13===e?7:h(e)?6:e>=97&&e<=122?0:e>=65&&e<=90?1:e>=48&&e<=57?2:-1===e?3:44===e||59===e?5:4}function R(e,t,i,n,o,a){let{moves:l,excludedChanges:c}=function(e,t,i,s){const n=[],r=e.filter((e=>e.modified.isEmpty&&e.original.length>=3)).map((e=>new d(e.original,t,e))),o=new Set(e.filter((e=>e.original.isEmpty&&e.modified.length>=3)).map((e=>new d(e.modified,i,e)))),a=new Set;for(const l of r){let e,t=-1;for(const i of o){const s=l.computeSimilarity(i);s>t&&(t=s,e=i)}if(t>.9&&e&&(o.delete(e),n.push(new _.WL(l.range,e.range)),a.add(l.source),a.add(e.source)),!s.isValid())return{moves:n,excludedChanges:a}}return{moves:n,excludedChanges:a}}(e,t,i,a);if(!a.isValid())return[];const h=function(e,t,i,n,o,a){const l=[],c=new C.db;for(const s of e)for(let e=s.original.startLineNumber;ee.modified.startLineNumber),s.U9));for(const s of e){let e=[];for(let t=s.modified.startLineNumber;t{for(const s of e)if(s.originalLineRange.endLineNumberExclusive+1===t.endLineNumberExclusive&&s.modifiedLineRange.endLineNumberExclusive+1===n.endLineNumberExclusive)return s.originalLineRange=new r.M(s.originalLineRange.startLineNumber,t.endLineNumberExclusive),s.modifiedLineRange=new r.M(s.modifiedLineRange.startLineNumber,n.endLineNumberExclusive),void o.push(s);const i={modifiedLineRange:n,originalLineRange:t};h.push(i),o.push(i)})),e=o}if(!a.isValid())return[]}h.sort((0,s.Hw)((0,s.VE)((e=>e.modifiedLineRange.length),s.U9)));const d=new r.S,u=new r.S;for(const s of h){const e=s.modifiedLineRange.startLineNumber-s.originalLineRange.startLineNumber,t=d.subtractFrom(s.modifiedLineRange),i=u.subtractFrom(s.originalLineRange).getWithDelta(e),n=t.getIntersection(i);for(const s of n.ranges){if(s.length<3)continue;const t=s,i=s.delta(-e);l.push(new _.WL(i,t)),d.addRange(t),u.addRange(i)}}l.sort((0,s.VE)((e=>e.original.startLineNumber),s.U9));const g=new v.vJ(e);for(let s=0;se.original.startLineNumber<=t.original.startLineNumber)),c=(0,v.lx)(e,(e=>e.modified.startLineNumber<=t.modified.startLineNumber)),h=Math.max(t.original.startLineNumber-i.original.startLineNumber,t.modified.startLineNumber-c.modified.startLineNumber),p=g.findLastMonotonous((e=>e.original.startLineNumbere.modified.startLineNumbern.length||i>o.length)break;if(d.contains(i)||u.contains(e))break;if(!T(n[e-1],o[i-1],a))break}for(C>0&&(u.addRange(new r.M(t.original.startLineNumber-C,t.original.startLineNumber)),d.addRange(new r.M(t.modified.startLineNumber-C,t.modified.startLineNumber))),b=0;bn.length||i>o.length)break;if(d.contains(i)||u.contains(e))break;if(!T(n[e-1],o[i-1],a))break}b>0&&(u.addRange(new r.M(t.original.endLineNumberExclusive,t.original.endLineNumberExclusive+b)),d.addRange(new r.M(t.modified.endLineNumberExclusive,t.modified.endLineNumberExclusive+b))),(C>0||b>0)&&(l[s]=new _.WL(new r.M(t.original.startLineNumber-C,t.original.endLineNumberExclusive+b),new r.M(t.modified.startLineNumber-C,t.modified.endLineNumberExclusive+b)))}return l}(e.filter((e=>!c.has(e))),n,o,t,i,a);return(0,s.E4)(l,h),l=function(e){if(0===e.length)return e;e.sort((0,s.VE)((e=>e.original.startLineNumber),s.U9));const t=[e[0]];for(let i=1;i=0&&o>=0&&r+o<=2?t[t.length-1]=s.join(n):t.push(n)}return t}(l),l=l.filter((e=>{const i=e.original.toOffsetRange().slice(t).map((e=>e.trim()));return i.join("\n").length>=15&&function(e,t){let i=0;for(const s of e)t(s)&&i++;return i}(i,(e=>e.length>=2))>=2})),l=function(e,t){const i=new v.vJ(e);return t=t.filter((t=>(i.findLastMonotonous((e=>e.original.startLineNumbere.modified.startLineNumber300&&t.length>300)return!1;const s=(new g).compute(new E([e],new a.Q(1,1,1,e.length),!1),new E([t],new a.Q(1,1,1,t.length),!1),i);let n=0;const r=l.$8.invert(s.diffs,e.length);for(const a of r)a.seq1Range.forEach((t=>{h(e.charCodeAt(t))||n++}));const o=function(t){let i=0;for(let s=0;st.length?e:t);return n/o>.6&&o>10}var x=i(82518);class k{constructor(e,t){this.trimmedHash=e,this.lines=t}getElement(e){return this.trimmedHash[e]}get length(){return this.trimmedHash.length}getBoundaryScore(e){return 1e3-((0===e?0:A(this.lines[e-1]))+(e===this.lines.length?0:A(this.lines[e])))}getText(e){return this.lines.slice(e.start,e.endExclusive).join("\n")}isStronglyEqual(e,t){return this.lines[e]===this.lines[t]}}function A(e){let t=0;for(;te===t)))return new N.p([],[],!1);if(1===e.length&&0===e[0].length||1===t.length&&0===t[0].length)return new N.p([new _.wm(new r.M(1,e.length+1),new r.M(1,t.length+1),[new _.q6(new a.Q(1,1,e.length,e[e.length-1].length+1),new a.Q(1,1,t.length,t[t.length-1].length+1))])],[],!1);const c=0===i.maxComputationTimeMs?l.uY.instance:new l.aY(i.maxComputationTimeMs),h=!i.ignoreTrimWhitespace,d=new Map;function u(e){let t=d.get(e);return void 0===t&&(t=d.size,d.set(e,t)),t}const g=e.map((e=>u(e.trim()))),p=t.map((e=>u(e.trim()))),m=new k(g,e),f=new k(p,t),v=(()=>m.length+f.length<1700?this.dynamicProgrammingDiffing.compute(m,f,c,((i,s)=>e[i]===t[s]?0===t[s].length?.1:1+Math.log(1+t[s].length):.99)):this.myersDiffingAlgorithm.compute(m,f,c))();let C=v.diffs,b=v.hitTimeout;C=(0,x.NC)(m,f,C),C=(0,x.X5)(m,f,C);const E=[],S=i=>{if(h)for(let s=0;ss.seq1Range.start-y===s.seq2Range.start-w));S(s.seq1Range.start-y),y=s.seq1Range.endExclusive,w=s.seq2Range.endExclusive;const i=this.refineDiff(e,t,s,c,h);i.hitTimeout&&(b=!0);for(const e of i.mappings)E.push(e)}S(e.length-y);const L=O(E,e,t);let R=[];return i.computeMoves&&(R=this.computeMoves(L,e,t,g,p,c,h)),(0,n.Ft)((()=>{function i(e,t){if(e.lineNumber<1||e.lineNumber>t.length)return!1;const i=t[e.lineNumber-1];return!(e.column<1||e.column>i.length+1)}function s(e,t){return!(e.startLineNumber<1||e.startLineNumber>t.length+1)&&!(e.endLineNumberExclusive<1||e.endLineNumberExclusive>t.length+1)}for(const n of L){if(!n.innerChanges)return!1;for(const s of n.innerChanges){if(!(i(s.modifiedRange.getStartPosition(),t)&&i(s.modifiedRange.getEndPosition(),t)&&i(s.originalRange.getStartPosition(),e)&&i(s.originalRange.getEndPosition(),e)))return!1}if(!s(n.modified,t)||!s(n.original,e))return!1}return!0})),new N.p(L,R,b)}computeMoves(e,t,i,s,n,r,o){return R(e,t,i,s,n,r).map((e=>{const s=O(this.refineDiff(t,i,new l.$8(e.original.toOffsetRange(),e.modified.toOffsetRange()),r,o).mappings,t,i,!0);return new N.t(e,s)}))}refineDiff(e,t,i,s,n){var o;const a=(o=i,new _.WL(new r.M(o.seq1Range.start+1,o.seq1Range.endExclusive+1),new r.M(o.seq2Range.start+1,o.seq2Range.endExclusive+1))).toRangeMapping2(e,t),l=new E(e,a.originalRange,n),c=new E(t,a.modifiedRange,n),h=l.length+c.length<500?this.dynamicProgrammingDiffing.compute(l,c,s):this.myersDiffingAlgorithm.compute(l,c,s),d=!1;let u=h.diffs;u=(0,x.NC)(l,c,u),u=(0,x.Lk)(l,c,u),u=(0,x.sq)(l,c,u),u=(0,x.Rl)(l,c,u);const g=u.map((e=>new _.q6(l.translateRange(e.seq1Range),c.translateRange(e.seq2Range))));return{mappings:g,hitTimeout:h.hitTimeout}}}function O(e,t,i,o=!1){const a=[];for(const n of(0,s.n)(e.map((e=>function(e,t,i){let s=0,n=0;1===e.modifiedRange.endColumn&&1===e.originalRange.endColumn&&e.originalRange.startLineNumber+s<=e.originalRange.endLineNumber&&e.modifiedRange.startLineNumber+s<=e.modifiedRange.endLineNumber&&(n=-1);e.modifiedRange.startColumn-1>=i[e.modifiedRange.startLineNumber-1].length&&e.originalRange.startColumn-1>=t[e.originalRange.startLineNumber-1].length&&e.originalRange.startLineNumber<=e.originalRange.endLineNumber+n&&e.modifiedRange.startLineNumber<=e.modifiedRange.endLineNumber+n&&(s=1);const o=new r.M(e.originalRange.startLineNumber+s,e.originalRange.endLineNumber+1+n),a=new r.M(e.modifiedRange.startLineNumber+s,e.modifiedRange.endLineNumber+1+n);return new _.wm(o,a,[e])}(e,t,i))),((e,t)=>e.original.overlapOrTouch(t.original)||e.modified.overlapOrTouch(t.modified)))){const e=n[0],t=n[n.length-1];a.push(new _.wm(e.original.join(t.original),e.modified.join(t.modified),n.map((e=>e.innerChanges[0]))))}return(0,n.Ft)((()=>{if(!o&&a.length>0){if(a[0].modified.startLineNumber!==a[0].original.startLineNumber)return!1;if(i.length-a[a.length-1].modified.endLineNumberExclusive!==t.length-a[a.length-1].original.endLineNumberExclusive)return!1}return(0,n.Xo)(a,((e,t)=>t.original.startLineNumber-e.original.endLineNumberExclusive===t.modified.startLineNumber-e.modified.endLineNumberExclusive&&e.original.endLineNumberExclusive{"use strict";i.d(t,{Lk:()=>h,NC:()=>o,Rl:()=>u,X5:()=>d,sq:()=>c});var s=i(25890),n=i(74444),r=i(68938);function o(e,t,i){let s=i;return s=a(e,t,s),s=a(e,t,s),s=function(e,t,i){if(!e.getBoundaryScore||!t.getBoundaryScore)return i;for(let s=0;s0?i[s-1]:void 0,o=i[s],a=s+10&&(l=l.delta(c))}o.push(l)}return s.length>0&&o.push(s[s.length-1]),o}function l(e,t,i,s,n){let r=1;for(;e.seq1Range.start-r>=s.start&&e.seq2Range.start-r>=n.start&&i.isStronglyEqual(e.seq2Range.start-r,e.seq2Range.endExclusive-r)&&r<100;)r++;r--;let o=0;for(;e.seq1Range.start+ol&&(l=o,a=c)}return e.delta(a)}function c(e,t,i){const s=[];for(const n of i){const e=s[s.length-1];e?n.seq1Range.start-e.seq1Range.endExclusive<=2||n.seq2Range.start-e.seq2Range.endExclusive<=2?s[s.length-1]=new r.$8(e.seq1Range.join(n.seq1Range),e.seq2Range.join(n.seq2Range)):s.push(n):s.push(n)}return s}function h(e,t,i){const s=r.$8.invert(i,e.length),n=[];let o=new r._3(0,0);function a(i,a){if(i.offset10;){const i=s[0];if(!(i.seq1Range.intersects(h.seq1Range)||i.seq2Range.intersects(h.seq2Range)))break;const n=e.findWordContaining(i.seq1Range.start),o=t.findWordContaining(i.seq2Range.start),a=new r.$8(n,o),l=a.intersect(i);if(u+=l.seq1Range.length,g+=l.seq2Range.length,h=h.join(a),!(h.seq1Range.endExclusive>=i.seq1Range.endExclusive))break;s.shift()}u+g<2*(h.seq1Range.length+h.seq2Range.length)/3&&n.push(h),o=h.getEndExclusives()}for(;s.length>0;){const e=s.shift();e.seq1Range.isEmpty||(a(e.getStarts(),e),a(e.getEndExclusives().delta(-1),e))}return function(e,t){const i=[];for(;e.length>0||t.length>0;){const s=e[0],n=t[0];let r;r=s&&(!n||s.seq1Range.start0&&i[i.length-1].seq1Range.endExclusive>=r.seq1Range.start?i[i.length-1]=i[i.length-1].join(r):i.push(r)}return i}(i,n)}function d(e,t,i){let s=i;if(0===s.length)return s;let r,o=0;do{r=!1;const a=[s[0]];for(let l=1;l5||i.seq1Range.length+i.seq2Range.length>5)}d(h,c)?(r=!0,a[a.length-1]=a[a.length-1].join(c)):a.push(c)}s=a}while(o++<10&&r);return s}function u(e,t,i){let o=i;if(0===o.length)return o;let a,l=0;do{a=!1;const h=[o[0]];for(let d=1;d5||r.length>500)return!1;const o=e.getText(r).trim();if(o.length>20||o.split(/\r\n|\r|\n/).length>1)return!1;const a=e.countLinesIn(i.seq1Range),l=i.seq1Range.length,c=t.countLinesIn(i.seq2Range),h=i.seq2Range.length,d=e.countLinesIn(s.seq1Range),p=s.seq1Range.length,m=t.countLinesIn(s.seq2Range),f=s.seq2Range.length;function _(e){return Math.min(e,130)}return Math.pow(Math.pow(_(40*a+l),1.5)+Math.pow(_(40*c+h),1.5),1.5)+Math.pow(Math.pow(_(40*d+p),1.5)+Math.pow(_(40*m+f),1.5),1.5)>74184.96480721243}p(g,u)?(a=!0,h[h.length-1]=h[h.length-1].join(u)):h.push(u)}o=h}while(l++<10&&a);const c=[];return(0,s.kj)(o,((t,i,s)=>{let o=i;function a(e){return e.length>0&&e.trim().length<=3&&i.seq1Range.length+i.seq2Range.length>100}const l=e.extendToFullLines(i.seq1Range),h=e.getText(new n.L(l.start,i.seq1Range.start));a(h)&&(o=o.deltaStart(-h.length));const d=e.getText(new n.L(i.seq1Range.endExclusive,l.endExclusive));a(d)&&(o=o.deltaEnd(d.length));const u=r.$8.fromOffsetPairs(t?t.getEndExclusives():r._3.zero,s?s.getStarts():r._3.max),g=o.intersect(u);c.length>0&&g.getStarts().equals(c[c.length-1].getEndExclusives())?c[c.length-1]=c[c.length-1].join(g):c.push(g)})),c}},41845:(e,t,i)=>{"use strict";i.d(t,{p:()=>s,t:()=>n});class s{constructor(e,t,i){this.changes=e,this.moves=t,this.hitTimeout=i}}class n{constructor(e,t){this.lineRangeMapping=e,this.changes=t}}},87723:(e,t,i)=>{"use strict";i.d(t,{WL:()=>l,q6:()=>u,wm:()=>d});var s=i(64383),n=i(86571),r=i(83069),o=i(36677),a=i(75295);class l{static inverse(e,t,i){const s=[];let r=1,o=1;for(const c of e){const e=new l(new n.M(r,c.original.startLineNumber),new n.M(o,c.modified.startLineNumber));e.modified.isEmpty||s.push(e),r=c.original.endLineNumberExclusive,o=c.modified.endLineNumberExclusive}const a=new l(new n.M(r,t+1),new n.M(o,i+1));return a.modified.isEmpty||s.push(a),s}static clip(e,t,i){const s=[];for(const n of e){const e=n.original.intersect(t),r=n.modified.intersect(i);e&&!e.isEmpty&&r&&!r.isEmpty&&s.push(new l(e,r))}return s}constructor(e,t){this.original=e,this.modified=t}toString(){return`{${this.original.toString()}->${this.modified.toString()}}`}flip(){return new l(this.modified,this.original)}join(e){return new l(this.original.join(e.original),this.modified.join(e.modified))}toRangeMapping(){const e=this.original.toInclusiveRange(),t=this.modified.toInclusiveRange();if(e&&t)return new u(e,t);if(1===this.original.startLineNumber||1===this.modified.startLineNumber){if(1!==this.modified.startLineNumber||1!==this.original.startLineNumber)throw new s.D7("not a valid diff");return new u(new o.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new o.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1))}return new u(new o.Q(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),new o.Q(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER,this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER))}toRangeMapping2(e,t){if(h(this.original.endLineNumberExclusive,e)&&h(this.modified.endLineNumberExclusive,t))return new u(new o.Q(this.original.startLineNumber,1,this.original.endLineNumberExclusive,1),new o.Q(this.modified.startLineNumber,1,this.modified.endLineNumberExclusive,1));if(!this.original.isEmpty&&!this.modified.isEmpty)return new u(o.Q.fromPositions(new r.y(this.original.startLineNumber,1),c(new r.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),o.Q.fromPositions(new r.y(this.modified.startLineNumber,1),c(new r.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));if(this.original.startLineNumber>1&&this.modified.startLineNumber>1)return new u(o.Q.fromPositions(c(new r.y(this.original.startLineNumber-1,Number.MAX_SAFE_INTEGER),e),c(new r.y(this.original.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),e)),o.Q.fromPositions(c(new r.y(this.modified.startLineNumber-1,Number.MAX_SAFE_INTEGER),t),c(new r.y(this.modified.endLineNumberExclusive-1,Number.MAX_SAFE_INTEGER),t)));throw new s.D7}}function c(e,t){if(e.lineNumber<1)return new r.y(1,1);if(e.lineNumber>t.length)return new r.y(t.length,t[t.length-1].length+1);const i=t[e.lineNumber-1];return e.column>i.length+1?new r.y(e.lineNumber,i.length+1):e}function h(e,t){return e>=1&&e<=t.length}class d extends l{static fromRangeMappings(e){const t=n.M.join(e.map((e=>n.M.fromRangeInclusive(e.originalRange)))),i=n.M.join(e.map((e=>n.M.fromRangeInclusive(e.modifiedRange))));return new d(t,i,e)}constructor(e,t,i){super(e,t),this.innerChanges=i}flip(){return new d(this.modified,this.original,this.innerChanges?.map((e=>e.flip())))}withInnerChangesFromLineRanges(){return new d(this.original,this.modified,[this.toRangeMapping()])}}class u{static assertSorted(e){for(let t=1;t${this.modifiedRange.toString()}}`}flip(){return new u(this.modifiedRange,this.originalRange)}toTextEdit(e){const t=e.getValueOfRange(this.modifiedRange);return new a.WR(this.originalRange,t)}}},29611:(e,t,i)=>{"use strict";i.d(t,{f:()=>s});class s{constructor(e,t,i,s,n,r,o){this.id=e,this.label=t,this.alias=i,this.metadata=s,this._precondition=n,this._run=r,this._contextKeyService=o}isSupported(){return this._contextKeyService.contextMatchesRules(this._precondition)}run(e){return this.isSupported()?this._run(e):Promise.resolve(void 0)}}},23452:(e,t,i)=>{"use strict";i.d(t,{_:()=>s});const s={ICodeEditor:"vs.editor.ICodeEditor",IDiffEditor:"vs.editor.IDiffEditor"}},60002:(e,t,i)=>{"use strict";i.d(t,{R:()=>s});var s,n=i(78209),r=i(32848);!function(e){e.editorSimpleInput=new r.N1("editorSimpleInput",!1,!0),e.editorTextFocus=new r.N1("editorTextFocus",!1,n.kg("editorTextFocus","Whether the editor text has focus (cursor is blinking)")),e.focus=new r.N1("editorFocus",!1,n.kg("editorFocus","Whether the editor or an editor widget has focus (e.g. focus is in the find widget)")),e.textInputFocus=new r.N1("textInputFocus",!1,n.kg("textInputFocus","Whether an editor or a rich text input has focus (cursor is blinking)")),e.readOnly=new r.N1("editorReadonly",!1,n.kg("editorReadonly","Whether the editor is read-only")),e.inDiffEditor=new r.N1("inDiffEditor",!1,n.kg("inDiffEditor","Whether the context is a diff editor")),e.isEmbeddedDiffEditor=new r.N1("isEmbeddedDiffEditor",!1,n.kg("isEmbeddedDiffEditor","Whether the context is an embedded diff editor")),e.inMultiDiffEditor=new r.N1("inMultiDiffEditor",!1,n.kg("inMultiDiffEditor","Whether the context is a multi diff editor")),e.multiDiffEditorAllCollapsed=new r.N1("multiDiffEditorAllCollapsed",void 0,n.kg("multiDiffEditorAllCollapsed","Whether all files in multi diff editor are collapsed")),e.hasChanges=new r.N1("diffEditorHasChanges",!1,n.kg("diffEditorHasChanges","Whether the diff editor has changes")),e.comparingMovedCode=new r.N1("comparingMovedCode",!1,n.kg("comparingMovedCode","Whether a moved code block is selected for comparison")),e.accessibleDiffViewerVisible=new r.N1("accessibleDiffViewerVisible",!1,n.kg("accessibleDiffViewerVisible","Whether the accessible diff viewer is visible")),e.diffEditorRenderSideBySideInlineBreakpointReached=new r.N1("diffEditorRenderSideBySideInlineBreakpointReached",!1,n.kg("diffEditorRenderSideBySideInlineBreakpointReached","Whether the diff editor render side by side inline breakpoint is reached")),e.diffEditorInlineMode=new r.N1("diffEditorInlineMode",!1,n.kg("diffEditorInlineMode","Whether inline mode is active")),e.diffEditorOriginalWritable=new r.N1("diffEditorOriginalWritable",!1,n.kg("diffEditorOriginalWritable","Whether modified is writable in the diff editor")),e.diffEditorModifiedWritable=new r.N1("diffEditorModifiedWritable",!1,n.kg("diffEditorModifiedWritable","Whether modified is writable in the diff editor")),e.diffEditorOriginalUri=new r.N1("diffEditorOriginalUri","",n.kg("diffEditorOriginalUri","The uri of the original document")),e.diffEditorModifiedUri=new r.N1("diffEditorModifiedUri","",n.kg("diffEditorModifiedUri","The uri of the modified document")),e.columnSelection=new r.N1("editorColumnSelection",!1,n.kg("editorColumnSelection","Whether `editor.columnSelection` is enabled")),e.writable=e.readOnly.toNegated(),e.hasNonEmptySelection=new r.N1("editorHasSelection",!1,n.kg("editorHasSelection","Whether the editor has text selected")),e.hasOnlyEmptySelection=e.hasNonEmptySelection.toNegated(),e.hasMultipleSelections=new r.N1("editorHasMultipleSelections",!1,n.kg("editorHasMultipleSelections","Whether the editor has multiple selections")),e.hasSingleSelection=e.hasMultipleSelections.toNegated(),e.tabMovesFocus=new r.N1("editorTabMovesFocus",!1,n.kg("editorTabMovesFocus","Whether `Tab` will move focus out of the editor")),e.tabDoesNotMoveFocus=e.tabMovesFocus.toNegated(),e.isInEmbeddedEditor=new r.N1("isInEmbeddedEditor",!1,!0),e.canUndo=new r.N1("canUndo",!1,!0),e.canRedo=new r.N1("canRedo",!1,!0),e.hoverVisible=new r.N1("editorHoverVisible",!1,n.kg("editorHoverVisible","Whether the editor hover is visible")),e.hoverFocused=new r.N1("editorHoverFocused",!1,n.kg("editorHoverFocused","Whether the editor hover is focused")),e.stickyScrollFocused=new r.N1("stickyScrollFocused",!1,n.kg("stickyScrollFocused","Whether the sticky scroll is focused")),e.stickyScrollVisible=new r.N1("stickyScrollVisible",!1,n.kg("stickyScrollVisible","Whether the sticky scroll is visible")),e.standaloneColorPickerVisible=new r.N1("standaloneColorPickerVisible",!1,n.kg("standaloneColorPickerVisible","Whether the standalone color picker is visible")),e.standaloneColorPickerFocused=new r.N1("standaloneColorPickerFocused",!1,n.kg("standaloneColorPickerFocused","Whether the standalone color picker is focused")),e.inCompositeEditor=new r.N1("inCompositeEditor",void 0,n.kg("inCompositeEditor","Whether the editor is part of a larger editor (e.g. notebooks)")),e.notInCompositeEditor=e.inCompositeEditor.toNegated(),e.languageId=new r.N1("editorLangId","",n.kg("editorLangId","The language identifier of the editor")),e.hasCompletionItemProvider=new r.N1("editorHasCompletionItemProvider",!1,n.kg("editorHasCompletionItemProvider","Whether the editor has a completion item provider")),e.hasCodeActionsProvider=new r.N1("editorHasCodeActionsProvider",!1,n.kg("editorHasCodeActionsProvider","Whether the editor has a code actions provider")),e.hasCodeLensProvider=new r.N1("editorHasCodeLensProvider",!1,n.kg("editorHasCodeLensProvider","Whether the editor has a code lens provider")),e.hasDefinitionProvider=new r.N1("editorHasDefinitionProvider",!1,n.kg("editorHasDefinitionProvider","Whether the editor has a definition provider")),e.hasDeclarationProvider=new r.N1("editorHasDeclarationProvider",!1,n.kg("editorHasDeclarationProvider","Whether the editor has a declaration provider")),e.hasImplementationProvider=new r.N1("editorHasImplementationProvider",!1,n.kg("editorHasImplementationProvider","Whether the editor has an implementation provider")),e.hasTypeDefinitionProvider=new r.N1("editorHasTypeDefinitionProvider",!1,n.kg("editorHasTypeDefinitionProvider","Whether the editor has a type definition provider")),e.hasHoverProvider=new r.N1("editorHasHoverProvider",!1,n.kg("editorHasHoverProvider","Whether the editor has a hover provider")),e.hasDocumentHighlightProvider=new r.N1("editorHasDocumentHighlightProvider",!1,n.kg("editorHasDocumentHighlightProvider","Whether the editor has a document highlight provider")),e.hasDocumentSymbolProvider=new r.N1("editorHasDocumentSymbolProvider",!1,n.kg("editorHasDocumentSymbolProvider","Whether the editor has a document symbol provider")),e.hasReferenceProvider=new r.N1("editorHasReferenceProvider",!1,n.kg("editorHasReferenceProvider","Whether the editor has a reference provider")),e.hasRenameProvider=new r.N1("editorHasRenameProvider",!1,n.kg("editorHasRenameProvider","Whether the editor has a rename provider")),e.hasSignatureHelpProvider=new r.N1("editorHasSignatureHelpProvider",!1,n.kg("editorHasSignatureHelpProvider","Whether the editor has a signature help provider")),e.hasInlayHintsProvider=new r.N1("editorHasInlayHintsProvider",!1,n.kg("editorHasInlayHintsProvider","Whether the editor has an inline hints provider")),e.hasDocumentFormattingProvider=new r.N1("editorHasDocumentFormattingProvider",!1,n.kg("editorHasDocumentFormattingProvider","Whether the editor has a document formatting provider")),e.hasDocumentSelectionFormattingProvider=new r.N1("editorHasDocumentSelectionFormattingProvider",!1,n.kg("editorHasDocumentSelectionFormattingProvider","Whether the editor has a document selection formatting provider")),e.hasMultipleDocumentFormattingProvider=new r.N1("editorHasMultipleDocumentFormattingProvider",!1,n.kg("editorHasMultipleDocumentFormattingProvider","Whether the editor has multiple document formatting providers")),e.hasMultipleDocumentSelectionFormattingProvider=new r.N1("editorHasMultipleDocumentSelectionFormattingProvider",!1,n.kg("editorHasMultipleDocumentSelectionFormattingProvider","Whether the editor has multiple document selection formatting providers"))}(s||(s={}))},72466:(e,t,i)=>{"use strict";i.d(t,{T:()=>r,x:()=>n});const s=[];function n(e){s.push(e)}function r(){return s.slice(0)}},25982:(e,t,i)=>{"use strict";i.d(t,{x:()=>s});class s{static getLanguageId(e){return(255&e)>>>0}static getTokenType(e){return(768&e)>>>8}static containsBalancedBrackets(e){return 0!==(1024&e)}static getFontStyle(e){return(30720&e)>>>11}static getForeground(e){return(16744448&e)>>>15}static getBackground(e){return(4278190080&e)>>>24}static getClassNameFromMetadata(e){let t="mtk"+this.getForeground(e);const i=this.getFontStyle(e);return 1&i&&(t+=" mtki"),2&i&&(t+=" mtkb"),4&i&&(t+=" mtku"),8&i&&(t+=" mtks"),t}static getInlineStyleFromMetadata(e,t){const i=this.getForeground(e),s=this.getFontStyle(e);let n=`color: ${t[i]};`;1&s&&(n+="font-style: italic;"),2&s&&(n+="font-weight: bold;");let r="";return 4&s&&(r+=" underline"),8&s&&(r+=" line-through"),r&&(n+=`text-decoration:${r};`),n}static getPresentationFromMetadata(e){const t=this.getForeground(e),i=this.getFontStyle(e);return{foreground:t,italic:Boolean(1&i),bold:Boolean(2&i),underline:Boolean(4&i),strikethrough:Boolean(8&i)}}}},54459:(e,t,i)=>{"use strict";i.d(t,{f:()=>r});var s=i(46958),n=i(74027);function r(e,t,i,o,a,l){if(Array.isArray(e)){let s=0;for(const n of e){const e=r(n,t,i,o,a,l);if(10===e)return e;e>s&&(s=e)}return s}if("string"===typeof e)return o?"*"===e?5:e===i?10:0:0;if(e){const{language:r,pattern:c,scheme:h,hasAccessToAllModels:d,notebookType:u}=e;if(!o&&!d)return 0;u&&a&&(t=a);let g=0;if(h)if(h===t.scheme)g=10;else{if("*"!==h)return 0;g=5}if(r)if(r===i)g=10;else{if("*"!==r)return 0;g=Math.max(g,5)}if(u)if(u===l)g=10;else{if("*"!==u||void 0===l)return 0;g=Math.max(g,5)}if(c){let e;if(e="string"===typeof c?c:{...c,base:(0,n.S8)(c.base)},e!==t.fsPath&&!(0,s.YW)(e,t.fsPath))return 0;g=10}return g}return 0}},62083:(e,t,i)=>{"use strict";i.d(t,{uB:()=>T,HC:()=>d,Kb:()=>m,FX:()=>g,rY:()=>C,lO:()=>k,M$:()=>h,r4:()=>x,qw:()=>u,sm:()=>O,v_:()=>A,OV:()=>L,YT:()=>R,GE:()=>b,WA:()=>p,gP:()=>w,ou:()=>_,dG:()=>N,$M:()=>v,OB:()=>I,PK:()=>y,Iu:()=>E});var s=i(10350),n=i(79400),r=i(36677),o=i(41234),a=i(5662);class l{constructor(){this._tokenizationSupports=new Map,this._factories=new Map,this._onDidChange=new o.vl,this.onDidChange=this._onDidChange.event,this._colorMap=null}handleChange(e){this._onDidChange.fire({changedLanguages:e,changedColorMap:!1})}register(e,t){return this._tokenizationSupports.set(e,t),this.handleChange([e]),(0,a.s)((()=>{this._tokenizationSupports.get(e)===t&&(this._tokenizationSupports.delete(e),this.handleChange([e]))}))}get(e){return this._tokenizationSupports.get(e)||null}registerFactory(e,t){this._factories.get(e)?.dispose();const i=new c(this,e,t);return this._factories.set(e,i),(0,a.s)((()=>{const t=this._factories.get(e);t&&t===i&&(this._factories.delete(e),t.dispose())}))}async getOrCreate(e){const t=this.get(e);if(t)return t;const i=this._factories.get(e);return!i||i.isResolved?null:(await i.resolve(),this.get(e))}isResolved(e){if(this.get(e))return!0;const t=this._factories.get(e);return!(t&&!t.isResolved)}setColorMap(e){this._colorMap=e,this._onDidChange.fire({changedLanguages:Array.from(this._tokenizationSupports.keys()),changedColorMap:!0})}getColorMap(){return this._colorMap}getDefaultBackground(){return this._colorMap&&this._colorMap.length>2?this._colorMap[2]:null}}class c extends a.jG{get isResolved(){return this._isResolved}constructor(e,t,i){super(),this._registry=e,this._languageId=t,this._factory=i,this._isDisposed=!1,this._resolvePromise=null,this._isResolved=!1}dispose(){this._isDisposed=!0,super.dispose()}async resolve(){return this._resolvePromise||(this._resolvePromise=this._create()),this._resolvePromise}async _create(){const e=await this._factory.tokenizationSupport;this._isResolved=!0,e&&!this._isDisposed&&this._register(this._registry.register(this._languageId,e))}}var h,d,u,g,p,m,f=i(78209);class _{constructor(e,t,i){this.offset=e,this.type=t,this.language=i,this._tokenBrand=void 0}toString(){return"("+this.offset+", "+this.type+")"}}class v{constructor(e,t){this.tokens=e,this.endState=t,this._tokenizationResultBrand=void 0}}class C{constructor(e,t){this.tokens=e,this.endState=t,this._encodedTokenizationResultBrand=void 0}}!function(e){e[e.Increase=0]="Increase",e[e.Decrease=1]="Decrease"}(h||(h={})),function(e){const t=new Map;t.set(0,s.W.symbolMethod),t.set(1,s.W.symbolFunction),t.set(2,s.W.symbolConstructor),t.set(3,s.W.symbolField),t.set(4,s.W.symbolVariable),t.set(5,s.W.symbolClass),t.set(6,s.W.symbolStruct),t.set(7,s.W.symbolInterface),t.set(8,s.W.symbolModule),t.set(9,s.W.symbolProperty),t.set(10,s.W.symbolEvent),t.set(11,s.W.symbolOperator),t.set(12,s.W.symbolUnit),t.set(13,s.W.symbolValue),t.set(15,s.W.symbolEnum),t.set(14,s.W.symbolConstant),t.set(15,s.W.symbolEnum),t.set(16,s.W.symbolEnumMember),t.set(17,s.W.symbolKeyword),t.set(27,s.W.symbolSnippet),t.set(18,s.W.symbolText),t.set(19,s.W.symbolColor),t.set(20,s.W.symbolFile),t.set(21,s.W.symbolReference),t.set(22,s.W.symbolCustomColor),t.set(23,s.W.symbolFolder),t.set(24,s.W.symbolTypeParameter),t.set(25,s.W.account),t.set(26,s.W.issues),e.toIcon=function(e){let i=t.get(e);return i||(console.info("No codicon found for CompletionItemKind "+e),i=s.W.symbolProperty),i};const i=new Map;i.set("method",0),i.set("function",1),i.set("constructor",2),i.set("field",3),i.set("variable",4),i.set("class",5),i.set("struct",6),i.set("interface",7),i.set("module",8),i.set("property",9),i.set("event",10),i.set("operator",11),i.set("unit",12),i.set("value",13),i.set("constant",14),i.set("enum",15),i.set("enum-member",16),i.set("enumMember",16),i.set("keyword",17),i.set("snippet",27),i.set("text",18),i.set("color",19),i.set("file",20),i.set("reference",21),i.set("customcolor",22),i.set("folder",23),i.set("type-parameter",24),i.set("typeParameter",24),i.set("account",25),i.set("issue",26),e.fromString=function(e,t){let s=i.get(e);return"undefined"!==typeof s||t||(s=9),s}}(d||(d={})),function(e){e[e.Automatic=0]="Automatic",e[e.Explicit=1]="Explicit"}(u||(u={}));class b{constructor(e,t,i,s){this.range=e,this.text=t,this.completionKind=i,this.isSnippetText=s}equals(e){return r.Q.lift(this.range).equalsRange(e.range)&&this.text===e.text&&this.completionKind===e.completionKind&&this.isSnippetText===e.isSnippetText}}function E(e){return e&&n.r.isUri(e.uri)&&r.Q.isIRange(e.range)&&(r.Q.isIRange(e.originSelectionRange)||r.Q.isIRange(e.targetSelectionRange))}!function(e){e[e.Automatic=0]="Automatic",e[e.PasteAs=1]="PasteAs"}(g||(g={})),function(e){e[e.Invoke=1]="Invoke",e[e.TriggerCharacter=2]="TriggerCharacter",e[e.ContentChange=3]="ContentChange"}(p||(p={})),function(e){e[e.Text=0]="Text",e[e.Read=1]="Read",e[e.Write=2]="Write"}(m||(m={}));const S={17:(0,f.kg)("Array","array"),16:(0,f.kg)("Boolean","boolean"),4:(0,f.kg)("Class","class"),13:(0,f.kg)("Constant","constant"),8:(0,f.kg)("Constructor","constructor"),9:(0,f.kg)("Enum","enumeration"),21:(0,f.kg)("EnumMember","enumeration member"),23:(0,f.kg)("Event","event"),7:(0,f.kg)("Field","field"),0:(0,f.kg)("File","file"),11:(0,f.kg)("Function","function"),10:(0,f.kg)("Interface","interface"),19:(0,f.kg)("Key","key"),5:(0,f.kg)("Method","method"),1:(0,f.kg)("Module","module"),2:(0,f.kg)("Namespace","namespace"),20:(0,f.kg)("Null","null"),15:(0,f.kg)("Number","number"),18:(0,f.kg)("Object","object"),24:(0,f.kg)("Operator","operator"),3:(0,f.kg)("Package","package"),6:(0,f.kg)("Property","property"),14:(0,f.kg)("String","string"),22:(0,f.kg)("Struct","struct"),25:(0,f.kg)("TypeParameter","type parameter"),12:(0,f.kg)("Variable","variable")};function y(e,t){return(0,f.kg)("symbolAriaLabel","{0} ({1})",e,S[t])}var w,L,R,T,x;!function(e){const t=new Map;t.set(0,s.W.symbolFile),t.set(1,s.W.symbolModule),t.set(2,s.W.symbolNamespace),t.set(3,s.W.symbolPackage),t.set(4,s.W.symbolClass),t.set(5,s.W.symbolMethod),t.set(6,s.W.symbolProperty),t.set(7,s.W.symbolField),t.set(8,s.W.symbolConstructor),t.set(9,s.W.symbolEnum),t.set(10,s.W.symbolInterface),t.set(11,s.W.symbolFunction),t.set(12,s.W.symbolVariable),t.set(13,s.W.symbolConstant),t.set(14,s.W.symbolString),t.set(15,s.W.symbolNumber),t.set(16,s.W.symbolBoolean),t.set(17,s.W.symbolArray),t.set(18,s.W.symbolObject),t.set(19,s.W.symbolKey),t.set(20,s.W.symbolNull),t.set(21,s.W.symbolEnumMember),t.set(22,s.W.symbolStruct),t.set(23,s.W.symbolEvent),t.set(24,s.W.symbolOperator),t.set(25,s.W.symbolTypeParameter),e.toIcon=function(e){let i=t.get(e);return i||(console.info("No codicon found for SymbolKind "+e),i=s.W.symbolProperty),i}}(w||(w={}));class k{static{this.Comment=new k("comment")}static{this.Imports=new k("imports")}static{this.Region=new k("region")}static fromValue(e){switch(e){case"comment":return k.Comment;case"imports":return k.Imports;case"region":return k.Region}return new k(e)}constructor(e){this.value=e}}!function(e){e[e.AIGenerated=1]="AIGenerated"}(L||(L={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(R||(R={})),function(e){e.is=function(e){return!(!e||"object"!==typeof e)&&("string"===typeof e.id&&"string"===typeof e.title)}}(T||(T={})),function(e){e[e.Type=1]="Type",e[e.Parameter=2]="Parameter"}(x||(x={}));class A{constructor(e){this.createSupport=e,this._tokenizationSupport=null}dispose(){this._tokenizationSupport&&this._tokenizationSupport.then((e=>{e&&e.dispose()}))}get tokenizationSupport(){return this._tokenizationSupport||(this._tokenizationSupport=this.createSupport()),this._tokenizationSupport}}const N=new l,I=new l;var O;!function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(O||(O={}))},82365:(e,t,i)=>{"use strict";i.d(t,{$f:()=>a,MU:()=>l,Yb:()=>h,_t:()=>c,vn:()=>o});var s=i(91508),n=i(38566),r=i(27760);function o(e,t,i,o=!0,a){if(e<4)return null;const l=a.getLanguageConfiguration(t.tokenization.getLanguageId()).indentRulesSupport;if(!l)return null;const c=new r.no(t,l,a);if(i<=1)return{indentation:"",action:null};for(let s=i-1;s>0&&""===t.getLineContent(s);s--)if(1===s)return{indentation:"",action:null};const h=function(e,t,i){const s=e.tokenization.getLanguageIdAtPosition(t,0);if(t>1){let n,r=-1;for(n=t-1;n>=1;n--){if(e.tokenization.getLanguageIdAtPosition(n,0)!==s)return r;const t=e.getLineContent(n);if(!i.shouldIgnore(n)&&!/^\s+$/.test(t)&&""!==t)return n;r=n}}return-1}(t,i,c);if(h<0)return null;if(h<1)return{indentation:"",action:null};if(c.shouldIncrease(h)||c.shouldIndentNextLine(h)){const e=t.getLineContent(h);return{indentation:s.UU(e),action:n.l.Indent,line:h}}if(c.shouldDecrease(h)){const e=t.getLineContent(h);return{indentation:s.UU(e),action:null,line:h}}{if(1===h)return{indentation:s.UU(t.getLineContent(h)),action:null,line:h};const e=h-1,i=l.getIndentMetadata(t.getLineContent(e));if(!(3&i)&&4&i){let i=0;for(let t=e-1;t>0;t--)if(!c.shouldIndentNextLine(t)){i=t;break}return{indentation:s.UU(t.getLineContent(i+1)),action:null,line:i+1}}if(o)return{indentation:s.UU(t.getLineContent(h)),action:null,line:h};for(let r=h;r>0;r--){if(c.shouldIncrease(r))return{indentation:s.UU(t.getLineContent(r)),action:n.l.Indent,line:r};if(c.shouldIndentNextLine(r)){let e=0;for(let t=r-1;t>0;t--)if(!c.shouldIndentNextLine(r)){e=t;break}return{indentation:s.UU(t.getLineContent(e+1)),action:null,line:e+1}}if(c.shouldDecrease(r))return{indentation:s.UU(t.getLineContent(r)),action:null,line:r}}return{indentation:s.UU(t.getLineContent(1)),action:null,line:1}}}function a(e,t,i,a,l,c){if(e<4)return null;const h=c.getLanguageConfiguration(i);if(!h)return null;const d=c.getLanguageConfiguration(i).indentRulesSupport;if(!d)return null;const u=new r.no(t,d,c),g=o(e,t,a,void 0,c);if(g){const i=g.line;if(void 0!==i){let r=!0;for(let e=i;es===t?i:e.tokenization.getLineTokens(s),getLanguageId:()=>e.getLanguageId(),getLanguageIdAtPosition:(t,i)=>e.getLanguageIdAtPosition(t,i)},getLineContent:s=>s===t?i.getLineContent():e.getLineContent(s)};return s}(t,i.startLineNumber,g),f=(0,r.WR)(t,i.getStartPosition()),_=t.getLineContent(i.startLineNumber),v=s.UU(_),C=o(e,m,i.startLineNumber+1,void 0,l);if(!C){const e=f?v:p;return{beforeEnter:e,afterEnter:e}}let b=f?v:C.indentation;return C.action===n.l.Indent&&(b=a.shiftIndent(b)),h.shouldDecrease(u.getLineContent())&&(b=a.unshiftIndent(b)),{beforeEnter:f?v:p,afterEnter:b}}function c(e,t,i,a,l,c){const h=e.autoIndent;if(h<4)return null;if((0,r.WR)(t,i.getStartPosition()))return null;const d=t.getLanguageIdAtPosition(i.startLineNumber,i.startColumn),u=c.getLanguageConfiguration(d).indentRulesSupport;if(!u)return null;const g=new r.V(t,c).getProcessedTokenContextAroundRange(i),p=g.beforeRangeProcessedTokens.getLineContent(),m=g.afterRangeProcessedTokens.getLineContent(),f=p+m,_=p+a+m;if(!u.shouldDecrease(f)&&u.shouldDecrease(_)){const e=o(h,t,i.startLineNumber,!1,c);if(!e)return null;let s=e.indentation;return e.action!==n.l.Indent&&(s=l.unshiftIndent(s)),s}const v=i.startLineNumber-1;if(v>0){const n=t.getLineContent(v);if(u.shouldIndentNextLine(n)&&u.shouldIncrease(_)){const n=o(h,t,i.startLineNumber,!1,c),r=n?.indentation;if(void 0!==r){const n=t.getLineContent(i.startLineNumber),o=s.UU(n),c=l.shiftIndent(r)===o,h=/^\s*$/.test(f),d=e.autoClosingPairs.autoClosingPairsOpenByEnd.get(a),u=d&&d.length>0;if(c&&(u&&h))return r}}}return null}function h(e,t,i){const s=i.getLanguageConfiguration(e.getLanguageId()).indentRulesSupport;return s?t<1||t>e.getLineCount()?null:s.getIndentMetadata(e.getLineContent(t)):null}},63346:(e,t,i)=>{"use strict";i.d(t,{h:()=>o});var s=i(38566),n=i(17469),r=i(27760);function o(e,t,i,o){t.tokenization.forceTokenization(i.startLineNumber);const a=t.getLanguageIdAtPosition(i.startLineNumber,i.startColumn),l=o.getLanguageConfiguration(a);if(!l)return null;const c=new r.V(t,o).getProcessedTokenContextAroundRange(i),h=c.previousLineProcessedTokens.getLineContent(),d=c.beforeRangeProcessedTokens.getLineContent(),u=c.afterRangeProcessedTokens.getLineContent(),g=l.onEnter(e,h,d,u);if(!g)return null;const p=g.indentAction;let m=g.appendText;const f=g.removeText||0;m?p===s.l.Indent&&(m="\t"+m):m=p===s.l.Indent||p===s.l.IndentOutdent?"\t":"";let _=(0,n.Cw)(t,i.startLineNumber,i.startColumn);return f&&(_=_.substring(0,_.length-f)),{indentAction:p,appendText:m,removeText:f,indentation:_}}},10154:(e,t,i)=>{"use strict";i.d(t,{L:()=>s});const s=(0,i(63591).u1)("languageService")},38566:(e,t,i)=>{"use strict";var s;i.d(t,{GB:()=>r,i3:()=>n,l:()=>s}),function(e){e[e.None=0]="None",e[e.Indent=1]="Indent",e[e.IndentOutdent=2]="IndentOutdent",e[e.Outdent=3]="Outdent"}(s||(s={}));class n{constructor(e){if(this._neutralCharacter=null,this._neutralCharacterSearched=!1,this.open=e.open,this.close=e.close,this._inString=!0,this._inComment=!0,this._inRegEx=!0,Array.isArray(e.notIn))for(let t=0,i=e.notIn.length;t{"use strict";i.d(t,{JZ:()=>N,Cw:()=>M});var s=i(41234),n=i(5662),r=i(91508),o=i(26486),a=i(38566);class l{static{this.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_QUOTES=";:.,=}])> \n\t"}static{this.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_BRACKETS="'\"`;:.,=}])> \n\t"}constructor(e){if(e.autoClosingPairs?this._autoClosingPairs=e.autoClosingPairs.map((e=>new a.i3(e))):e.brackets?this._autoClosingPairs=e.brackets.map((e=>new a.i3({open:e[0],close:e[1]}))):this._autoClosingPairs=[],e.__electricCharacterSupport&&e.__electricCharacterSupport.docComment){const t=e.__electricCharacterSupport.docComment;this._autoClosingPairs.push(new a.i3({open:t.open,close:t.close||""}))}this._autoCloseBeforeForQuotes="string"===typeof e.autoCloseBefore?e.autoCloseBefore:l.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_QUOTES,this._autoCloseBeforeForBrackets="string"===typeof e.autoCloseBefore?e.autoCloseBefore:l.DEFAULT_AUTOCLOSE_BEFORE_LANGUAGE_DEFINED_BRACKETS,this._surroundingPairs=e.surroundingPairs||this._autoClosingPairs}getAutoClosingPairs(){return this._autoClosingPairs}getAutoCloseBeforeSet(e){return e?this._autoCloseBeforeForQuotes:this._autoCloseBeforeForBrackets}getSurroundingPairs(){return this._surroundingPairs}}var c=i(25890),h=i(12296),d=i(56772);class u{constructor(e){this._richEditBrackets=e}getElectricCharacters(){const e=[];if(this._richEditBrackets)for(const t of this._richEditBrackets.brackets)for(const i of t.close){const t=i.charAt(i.length-1);e.push(t)}return(0,c.dM)(e)}onElectricCharacter(e,t,i){if(!this._richEditBrackets||0===this._richEditBrackets.brackets.length)return null;const s=t.findTokenIndexAtOffset(i-1);if((0,h.Yo)(t.getStandardTokenType(s)))return null;const n=this._richEditBrackets.reversedRegex,r=t.getLineContent().substring(0,i-1)+e,o=d.Fu.findPrevBracketInRange(n,1,r,0,r.length);if(!o)return null;const a=r.substring(o.startColumn-1,o.endColumn-1).toLowerCase();if(this._richEditBrackets.textIsOpenBracket[a])return null;const l=t.getActualLineContentBefore(o.startColumn-1);return/^\s*$/.test(l)?{matchOpenBracket:a}:null}}function g(e){return e.global&&(e.lastIndex=0),!0}class p{constructor(e){this._indentationRules=e}shouldIncrease(e){return!!(this._indentationRules&&this._indentationRules.increaseIndentPattern&&g(this._indentationRules.increaseIndentPattern)&&this._indentationRules.increaseIndentPattern.test(e))}shouldDecrease(e){return!!(this._indentationRules&&this._indentationRules.decreaseIndentPattern&&g(this._indentationRules.decreaseIndentPattern)&&this._indentationRules.decreaseIndentPattern.test(e))}shouldIndentNextLine(e){return!!(this._indentationRules&&this._indentationRules.indentNextLinePattern&&g(this._indentationRules.indentNextLinePattern)&&this._indentationRules.indentNextLinePattern.test(e))}shouldIgnore(e){return!!(this._indentationRules&&this._indentationRules.unIndentedLinePattern&&g(this._indentationRules.unIndentedLinePattern)&&this._indentationRules.unIndentedLinePattern.test(e))}getIndentMetadata(e){let t=0;return this.shouldIncrease(e)&&(t+=1),this.shouldDecrease(e)&&(t+=2),this.shouldIndentNextLine(e)&&(t+=4),this.shouldIgnore(e)&&(t+=8),t}}var m=i(64383);class f{constructor(e){(e=e||{}).brackets=e.brackets||[["(",")"],["{","}"],["[","]"]],this._brackets=[],e.brackets.forEach((e=>{const t=f._createOpenBracketRegExp(e[0]),i=f._createCloseBracketRegExp(e[1]);t&&i&&this._brackets.push({open:e[0],openRegExp:t,close:e[1],closeRegExp:i})})),this._regExpRules=e.onEnterRules||[]}onEnter(e,t,i,s){if(e>=3)for(let n=0,r=this._regExpRules.length;n!e.reg||(e.reg.lastIndex=0,e.reg.test(e.text)))))return e.action}if(e>=2&&i.length>0&&s.length>0)for(let n=0,r=this._brackets.length;n=2&&i.length>0)for(let n=0,r=this._brackets.length;n{const t=new Set;return{info:new R(this,e,t),closing:t}})),n=new S.VV((e=>{const t=new Set,i=new Set;return{info:new T(this,e,t,i),opening:t,openingColorized:i}}));for(const[o,a]of i){const e=s.get(o),t=n.get(a);e.closing.add(t.info),t.opening.add(e.info)}const r=t.colorizedBracketPairs?w(t.colorizedBracketPairs):i.filter((e=>!("<"===e[0]&&">"===e[1])));for(const[o,a]of r){const e=s.get(o),t=n.get(a);e.closing.add(t.info),t.openingColorized.add(e.info),t.opening.add(e.info)}this._openingBrackets=new Map([...s.cachedValues].map((([e,t])=>[e,t.info]))),this._closingBrackets=new Map([...n.cachedValues].map((([e,t])=>[e,t.info])))}get openingBrackets(){return[...this._openingBrackets.values()]}get closingBrackets(){return[...this._closingBrackets.values()]}getOpeningBracketInfo(e){return this._openingBrackets.get(e)}getClosingBracketInfo(e){return this._closingBrackets.get(e)}getBracketInfo(e){return this.getOpeningBracketInfo(e)||this.getClosingBracketInfo(e)}getBracketRegExp(e){const t=Array.from([...this._openingBrackets.keys(),...this._closingBrackets.keys()]);return(0,d.xb)(t,e)}}function w(e){return e.filter((([e,t])=>""!==e&&""!==t))}class L{constructor(e,t){this.config=e,this.bracketText=t}get languageId(){return this.config.languageId}}class R extends L{constructor(e,t,i){super(e,t),this.openedBrackets=i,this.isOpeningBracket=!0}}class T extends L{constructor(e,t,i,s){super(e,t),this.openingBrackets=i,this.openingColorizedBrackets=s,this.isOpeningBracket=!1}closes(e){return e.config===this.config&&this.openingBrackets.has(e)}closesColorized(e){return e.config===this.config&&this.openingColorizedBrackets.has(e)}getOpeningBrackets(){return[...this.openingBrackets]}}var x=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},k=function(e,t){return function(i,s){t(i,s,e)}};class A{constructor(e){this.languageId=e}affects(e){return!this.languageId||this.languageId===e}}const N=(0,_.u1)("languageConfigurationService");let I=class extends n.jG{constructor(e,t){super(),this.configurationService=e,this.languageService=t,this._registry=this._register(new B),this.onDidChangeEmitter=this._register(new s.vl),this.onDidChange=this.onDidChangeEmitter.event,this.configurations=new Map;const i=new Set(Object.values(O));this._register(this.configurationService.onDidChangeConfiguration((e=>{const t=e.change.keys.some((e=>i.has(e))),s=e.change.overrides.filter((([e,t])=>t.some((e=>i.has(e))))).map((([e])=>e));if(t)this.configurations.clear(),this.onDidChangeEmitter.fire(new A(void 0));else for(const i of s)this.languageService.isRegisteredLanguageId(i)&&(this.configurations.delete(i),this.onDidChangeEmitter.fire(new A(i)))}))),this._register(this._registry.onDidChange((e=>{this.configurations.delete(e.languageId),this.onDidChangeEmitter.fire(new A(e.languageId))})))}register(e,t,i){return this._registry.register(e,t,i)}getLanguageConfiguration(e){let t=this.configurations.get(e);return t||(t=function(e,t,i,s){let n=t.getLanguageConfiguration(e);if(!n){if(!s.isRegisteredLanguageId(e))return new W(e,{});n=new W(e,{})}const r=function(e,t){const i=t.getValue(O.brackets,{overrideIdentifier:e}),s=t.getValue(O.colorizedBracketPairs,{overrideIdentifier:e});return{brackets:D(i),colorizedBracketPairs:D(s)}}(n.languageId,i),o=F([n.underlyingConfig,r]);return new W(n.languageId,o)}(e,this._registry,this.configurationService,this.languageService),this.configurations.set(e,t)),t}};I=x([k(0,v.pG),k(1,C.L)],I);const O={brackets:"editor.language.brackets",colorizedBracketPairs:"editor.language.colorizedBracketPairs"};function D(e){if(Array.isArray(e))return e.map((e=>{if(Array.isArray(e)&&2===e.length)return[e[0],e[1]]})).filter((e=>!!e))}function M(e,t,i){const s=e.getLineContent(t);let n=r.UU(s);return n.length>i-1&&(n=n.substring(0,i-1)),n}class P{constructor(e){this.languageId=e,this._resolved=null,this._entries=[],this._order=0,this._resolved=null}register(e,t){const i=new U(e,t,++this._order);return this._entries.push(i),this._resolved=null,(0,n.s)((()=>{for(let e=0;ee.configuration))))}}function F(e){let t={comments:void 0,brackets:void 0,wordPattern:void 0,indentationRules:void 0,onEnterRules:void 0,autoClosingPairs:void 0,surroundingPairs:void 0,autoCloseBefore:void 0,folding:void 0,colorizedBracketPairs:void 0,__electricCharacterSupport:void 0};for(const i of e)t={comments:i.comments||t.comments,brackets:i.brackets||t.brackets,wordPattern:i.wordPattern||t.wordPattern,indentationRules:i.indentationRules||t.indentationRules,onEnterRules:i.onEnterRules||t.onEnterRules,autoClosingPairs:i.autoClosingPairs||t.autoClosingPairs,surroundingPairs:i.surroundingPairs||t.surroundingPairs,autoCloseBefore:i.autoCloseBefore||t.autoCloseBefore,folding:i.folding||t.folding,colorizedBracketPairs:i.colorizedBracketPairs||t.colorizedBracketPairs,__electricCharacterSupport:i.__electricCharacterSupport||t.__electricCharacterSupport};return t}class U{constructor(e,t,i){this.configuration=e,this.priority=t,this.order=i}static cmp(e,t){return e.priority===t.priority?e.order-t.order:e.priority-t.priority}}class H{constructor(e){this.languageId=e}}class B extends n.jG{constructor(){super(),this._entries=new Map,this._onDidChange=this._register(new s.vl),this.onDidChange=this._onDidChange.event,this._register(this.register(E.vH,{brackets:[["(",")"],["[","]"],["{","}"]],surroundingPairs:[{open:"{",close:"}"},{open:"[",close:"]"},{open:"(",close:")"},{open:"<",close:">"},{open:'"',close:'"'},{open:"'",close:"'"},{open:"`",close:"`"}],colorizedBracketPairs:[],folding:{offSide:!0}},0))}register(e,t,i=0){let s=this._entries.get(e);s||(s=new P(e),this._entries.set(e,s));const r=s.register(t,i);return this._onDidChange.fire(new H(e)),(0,n.s)((()=>{r.dispose(),this._onDidChange.fire(new H(e))}))}getLanguageConfiguration(e){const t=this._entries.get(e);return t?.getResolvedConfiguration()||null}}class W{constructor(e,t){this.languageId=e,this.underlyingConfig=t,this._brackets=null,this._electricCharacter=null,this._onEnterSupport=this.underlyingConfig.brackets||this.underlyingConfig.indentationRules||this.underlyingConfig.onEnterRules?new f(this.underlyingConfig):null,this.comments=W._handleComments(this.underlyingConfig),this.characterPair=new l(this.underlyingConfig),this.wordDefinition=this.underlyingConfig.wordPattern||o.Ld,this.indentationRules=this.underlyingConfig.indentationRules,this.underlyingConfig.indentationRules?this.indentRulesSupport=new p(this.underlyingConfig.indentationRules):this.indentRulesSupport=null,this.foldingRules=this.underlyingConfig.folding||{},this.bracketsNew=new y(e,this.underlyingConfig)}getWordDefinition(){return(0,o.Io)(this.wordDefinition)}get brackets(){return!this._brackets&&this.underlyingConfig.brackets&&(this._brackets=new d.az(this.languageId,this.underlyingConfig.brackets)),this._brackets}get electricCharacter(){return this._electricCharacter||(this._electricCharacter=new u(this.brackets)),this._electricCharacter}onEnter(e,t,i,s){return this._onEnterSupport?this._onEnterSupport.onEnter(e,t,i,s):null}getAutoClosingPairs(){return new a.GB(this.characterPair.getAutoClosingPairs())}getAutoCloseBeforeSet(e){return this.characterPair.getAutoCloseBeforeSet(e)}getSurroundingPairs(){return this.characterPair.getSurroundingPairs()}static _handleComments(e){const t=e.comments;if(!t)return null;const i={};if(t.lineComment&&(i.lineCommentToken=t.lineComment),t.blockComment){const[e,s]=t.blockComment;i.blockCommentStartToken=e,i.blockCommentEndToken=s}return i}}(0,b.v)(N,I,1)},83941:(e,t,i)=>{"use strict";i.d(t,{W6:()=>l,vH:()=>c});var s=i(78209),n=i(41234),r=i(46359),o=i(44320),a=i(1646);const l=new class{constructor(){this._onDidChangeLanguages=new n.vl,this.onDidChangeLanguages=this._onDidChangeLanguages.event,this._languages=[]}registerLanguage(e){return this._languages.push(e),this._onDidChangeLanguages.fire(void 0),{dispose:()=>{for(let t=0,i=this._languages.length;t{"use strict";i.d(t,{$H:()=>r,Lh:()=>o,r3:()=>n});var s=i(62083);const n=new class{clone(){return this}equals(e){return this===e}};function r(e,t){return new s.$M([new s.ou(0,"",e)],t)}function o(e,t){const i=new Uint32Array(2);return i[0]=0,i[1]=(32768|e|2<<24)>>>0,new s.rY(i,null===t?n:t)}},12296:(e,t,i)=>{"use strict";function s(e,t){const i=e.getCount(),s=e.findTokenIndexAtOffset(t),r=e.getLanguageId(s);let o=s;for(;o+10&&e.getLanguageId(a-1)===r;)a--;return new n(e,r,a,o+1,e.getStartOffset(a),e.getEndOffset(o))}i.d(t,{BQ:()=>s,Yo:()=>r});class n{constructor(e,t,i,s,n,r){this._scopedLineTokensBrand=void 0,this._actual=e,this.languageId=t,this._firstTokenIndex=i,this._lastTokenIndex=s,this.firstCharOffset=n,this._lastCharOffset=r,this.languageIdCodec=e.languageIdCodec}getLineContent(){return this._actual.getLineContent().substring(this.firstCharOffset,this._lastCharOffset)}getLineLength(){return this._lastCharOffset-this.firstCharOffset}getActualLineContentBefore(e){return this._actual.getLineContent().substring(0,this.firstCharOffset+e)}getTokenCount(){return this._lastTokenIndex-this._firstTokenIndex}findTokenIndexAtOffset(e){return this._actual.findTokenIndexAtOffset(e+this.firstCharOffset)-this._firstTokenIndex}getStandardTokenType(e){return this._actual.getStandardTokenType(e+this._firstTokenIndex)}toIViewLineTokens(){return this._actual.sliceAndInflate(this.firstCharOffset,this._lastCharOffset,0)}}function r(e){return 0!==(3&e)}},27760:(e,t,i)=>{"use strict";i.d(t,{V:()=>a,WR:()=>c,no:()=>o});var s=i(91508),n=i(12296),r=i(87469);class o{constructor(e,t,i){this._indentRulesSupport=t,this._indentationLineProcessor=new l(e,i)}shouldIncrease(e,t){const i=this._indentationLineProcessor.getProcessedLine(e,t);return this._indentRulesSupport.shouldIncrease(i)}shouldDecrease(e,t){const i=this._indentationLineProcessor.getProcessedLine(e,t);return this._indentRulesSupport.shouldDecrease(i)}shouldIgnore(e,t){const i=this._indentationLineProcessor.getProcessedLine(e,t);return this._indentRulesSupport.shouldIgnore(i)}shouldIndentNextLine(e,t){const i=this._indentationLineProcessor.getProcessedLine(e,t);return this._indentRulesSupport.shouldIndentNextLine(i)}}class a{constructor(e,t){this.model=e,this.indentationLineProcessor=new l(e,t)}getProcessedTokenContextAroundRange(e){return{beforeRangeProcessedTokens:this._getProcessedTokensBeforeRange(e),afterRangeProcessedTokens:this._getProcessedTokensAfterRange(e),previousLineProcessedTokens:this._getProcessedPreviousLineTokens(e)}}_getProcessedTokensBeforeRange(e){this.model.tokenization.forceTokenization(e.startLineNumber);const t=this.model.tokenization.getLineTokens(e.startLineNumber),i=(0,n.BQ)(t,e.startColumn-1);let s;if(c(this.model,e.getStartPosition())){const n=e.startColumn-1-i.firstCharOffset,r=i.firstCharOffset,o=r+n;s=t.sliceAndInflate(r,o,0)}else{const i=e.startColumn-1;s=t.sliceAndInflate(0,i,0)}return this.indentationLineProcessor.getProcessedTokens(s)}_getProcessedTokensAfterRange(e){const t=e.isEmpty()?e.getStartPosition():e.getEndPosition();this.model.tokenization.forceTokenization(t.lineNumber);const i=this.model.tokenization.getLineTokens(t.lineNumber),s=(0,n.BQ)(i,t.column-1),r=t.column-1-s.firstCharOffset,o=s.firstCharOffset+r,a=s.firstCharOffset+s.getLineLength(),l=i.sliceAndInflate(o,a,0);return this.indentationLineProcessor.getProcessedTokens(l)}_getProcessedPreviousLineTokens(e){this.model.tokenization.forceTokenization(e.startLineNumber);const t=this.model.tokenization.getLineTokens(e.startLineNumber),i=(0,n.BQ)(t,e.startColumn-1),s=r.f.createEmpty("",i.languageIdCodec),o=e.startLineNumber-1;if(0===o)return s;if(!(0===i.firstCharOffset))return s;const a=(e=>{this.model.tokenization.forceTokenization(e);const t=this.model.tokenization.getLineTokens(e),i=this.model.getLineMaxColumn(e)-1;return(0,n.BQ)(t,i)})(o);if(!(i.languageId===a.languageId))return s;const l=a.toIViewLineTokens();return this.indentationLineProcessor.getProcessedTokens(l)}}class l{constructor(e,t){this.model=e,this.languageConfigurationService=t}getProcessedLine(e,t){this.model.tokenization.forceTokenization?.(e);const i=this.model.tokenization.getLineTokens(e);let n=this.getProcessedTokens(i).getLineContent();return void 0!==t&&(n=((e,t)=>{const i=s.UU(e);return t+e.substring(i.length)})(n,t)),n}getProcessedTokens(e){const t=e.getLanguageId(0),i=this.languageConfigurationService.getLanguageConfiguration(t).bracketsNew.getBracketRegExp({global:!0}),s=[];e.forEach((t=>{const n=e.getStandardTokenType(t);let r=e.getTokenText(t);(e=>2===e||3===e||1===e)(n)&&(r=r.replace(i,""));const o=e.getMetadata(t);s.push({text:r,metadata:o})}));return r.f.createFromTextAndMetadata(s,e.languageIdCodec)}}function c(e,t){e.tokenization.forceTokenization(t.lineNumber);const i=e.tokenization.getLineTokens(t.lineNumber),s=(0,n.BQ)(i,t.column-1),r=0===s.firstCharOffset,o=i.getLanguageId(0)===s.languageId;return!r&&!o}},56772:(e,t,i)=>{"use strict";i.d(t,{Fu:()=>p,az:()=>a,xb:()=>u});var s=i(91508),n=i(99020),r=i(36677);class o{constructor(e,t,i,s,n,r){this._richEditBracketBrand=void 0,this.languageId=e,this.index=t,this.open=i,this.close=s,this.forwardRegex=n,this.reversedRegex=r,this._openSet=o._toSet(this.open),this._closeSet=o._toSet(this.close)}isOpen(e){return this._openSet.has(e)}isClose(e){return this._closeSet.has(e)}static _toSet(e){const t=new Set;for(const i of e)t.add(i);return t}}class a{constructor(e,t){this._richEditBracketsBrand=void 0;const i=function(e){const t=e.length;e=e.map((e=>[e[0].toLowerCase(),e[1].toLowerCase()]));const i=[];for(let o=0;o{const[i,s]=e,[n,r]=t;return i===n||i===r||s===n||s===r},n=(e,s)=>{const n=Math.min(e,s),r=Math.max(e,s);for(let o=0;o0&&r.push({open:s,close:n})}return r}(t);this.brackets=i.map(((t,s)=>new o(e,s,t.open,t.close,function(e,t,i,s){let n=[];n=n.concat(e),n=n.concat(t);for(let r=0,o=n.length;r=0&&s.push(t);for(const t of r.close)t.indexOf(e)>=0&&s.push(t)}}function c(e,t){return e.length-t.length}function h(e){if(e.length<=1)return e;const t=[],i=new Set;for(const s of e)i.has(s)||(t.push(s),i.add(s));return t}function d(e){const t=/^[\w ]+$/.test(e);return e=s.bm(e),t?`\\b${e}\\b`:e}function u(e,t){const i=`(${e.map(d).join(")|(")})`;return s.OS(i,!0,t)}const g=function(){let e=null,t=null;return function(i){return e!==i&&(e=i,t=function(e){const t=new Uint16Array(e.length);let i=0;for(let s=e.length-1;s>=0;s--)t[i++]=e.charCodeAt(s);return n.b7().decode(t)}(e)),t}}();class p{static _findPrevBracketInText(e,t,i,s){const n=i.match(e);if(!n)return null;const o=i.length-(n.index||0),a=n[0].length,l=s+o;return new r.Q(t,l-a+1,t,l+1)}static findPrevBracketInRange(e,t,i,s,n){const r=g(i).substring(i.length-n,i.length-s);return this._findPrevBracketInText(e,t,r,s)}static findNextBracketInText(e,t,i,s){const n=i.match(e);if(!n)return null;const o=n.index||0,a=n[0].length;if(0===a)return null;const l=s+o;return new r.Q(t,l+1,t,l+1+a)}static findNextBracketInRange(e,t,i,s,n){const r=i.substring(s,n);return this.findNextBracketInText(e,t,r,s)}}},58314:(e,t,i)=>{"use strict";i.d(t,{Yj:()=>l,s0:()=>c});var s=i(91508),n=i(87469),r=i(62083),o=i(20788);const a={getInitialState:()=>o.r3,tokenizeEncoded:(e,t,i)=>(0,o.Lh)(0,i)};async function l(e,t,i){if(!i)return h(t,e.languageIdCodec,a);const s=await r.dG.getOrCreate(i);return h(t,e.languageIdCodec,s||a)}function c(e,t,i,s,n,r,o){let a="
    ",l=s,c=0,h=!0;for(let d=0,u=t.getCount();d0;)o&&h?(g+=" ",h=!1):(g+=" ",h=!0),e--;break}case 60:g+="<",h=!1;break;case 62:g+=">",h=!1;break;case 38:g+="&",h=!1;break;case 0:g+="�",h=!1;break;case 65279:case 8232:case 8233:case 133:g+="\ufffd",h=!1;break;case 13:g+="​",h=!1;break;case 32:o&&h?(g+=" ",h=!1):(g+=" ",h=!0);break;default:g+=String.fromCharCode(t),h=!1}}if(a+=`${g}`,u>n||l>=n)break}return a+="
    ",a}function h(e,t,i){let r='
    ';const o=s.uz(e);let a=i.getInitialState();for(let l=0,c=o.length;l0&&(r+="
    ");const c=i.tokenizeEncoded(e,!0,a);n.f.convertToEndOffset(c.tokens,e.length);const h=new n.f(c.tokens,e,t).inflate();let d=0;for(let t=0,i=h.getCount();t${s.ih(e.substring(d,n))}`,d=n}a=c.endState}return r+="
    ",r}},16223:(e,t,i)=>{"use strict";i.d(t,{A5:()=>s,Dg:()=>l,F4:()=>u,L5:()=>d,VW:()=>r,Wo:()=>h,X2:()=>a,ZS:()=>n,nk:()=>c,vd:()=>g});var s,n,r,o=i(10146);!function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=4]="Right",e[e.Full=7]="Full"}(s||(s={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=3]="Right"}(n||(n={})),function(e){e[e.Both=0]="Both",e[e.Right=1]="Right",e[e.Left=2]="Left",e[e.None=3]="None"}(r||(r={}));class a{get originalIndentSize(){return this._indentSizeIsTabSize?"tabSize":this.indentSize}constructor(e){this._textModelResolvedOptionsBrand=void 0,this.tabSize=Math.max(1,0|e.tabSize),"tabSize"===e.indentSize?(this.indentSize=this.tabSize,this._indentSizeIsTabSize=!0):(this.indentSize=Math.max(1,0|e.indentSize),this._indentSizeIsTabSize=!1),this.insertSpaces=Boolean(e.insertSpaces),this.defaultEOL=0|e.defaultEOL,this.trimAutoWhitespace=Boolean(e.trimAutoWhitespace),this.bracketPairColorizationOptions=e.bracketPairColorizationOptions}equals(e){return this.tabSize===e.tabSize&&this._indentSizeIsTabSize===e._indentSizeIsTabSize&&this.indentSize===e.indentSize&&this.insertSpaces===e.insertSpaces&&this.defaultEOL===e.defaultEOL&&this.trimAutoWhitespace===e.trimAutoWhitespace&&(0,o.aI)(this.bracketPairColorizationOptions,e.bracketPairColorizationOptions)}createChangeEvent(e){return{tabSize:this.tabSize!==e.tabSize,indentSize:this.indentSize!==e.indentSize,insertSpaces:this.insertSpaces!==e.insertSpaces,trimAutoWhitespace:this.trimAutoWhitespace!==e.trimAutoWhitespace}}}class l{constructor(e,t){this._findMatchBrand=void 0,this.range=e,this.matches=t}}function c(e){return e&&"function"===typeof e.read}class h{constructor(e,t,i,s,n,r){this.identifier=e,this.range=t,this.text=i,this.forceMoveMarkers=s,this.isAutoWhitespaceEdit=n,this._isTracked=r}}class d{constructor(e,t,i){this.regex=e,this.wordSeparators=t,this.simpleSearch=i}}class u{constructor(e,t,i){this.reverseEdits=e,this.changes=t,this.trimAutoWhitespaceLineNumbers=i}}function g(e){return!e.isTooLargeForSyncing()&&!e.isForSimpleWidget}},40579:(e,t,i)=>{"use strict";i.d(t,{Gc:()=>v,Nn:()=>l,Xw:()=>c,rh:()=>_,yF:()=>f});var s=i(64383),n=i(1245),r=i(19131),o=i(32956);class a{get length(){return this._length}constructor(e){this._length=e}}class l extends a{static create(e,t,i){let s=e.length;return t&&(s=(0,r.QB)(s,t.length)),i&&(s=(0,r.QB)(s,i.length)),new l(s,e,t,i,t?t.missingOpeningBracketIds:o.gV.getEmpty())}get kind(){return 2}get listHeight(){return 0}get childrenLength(){return 3}getChild(e){switch(e){case 0:return this.openingBracket;case 1:return this.child;case 2:return this.closingBracket}throw new Error("Invalid child index")}get children(){const e=[];return e.push(this.openingBracket),this.child&&e.push(this.child),this.closingBracket&&e.push(this.closingBracket),e}constructor(e,t,i,s,n){super(e),this.openingBracket=t,this.child=i,this.closingBracket=s,this.missingOpeningBracketIds=n}canBeReused(e){return null!==this.closingBracket&&!e.intersects(this.missingOpeningBracketIds)}deepClone(){return new l(this.length,this.openingBracket.deepClone(),this.child&&this.child.deepClone(),this.closingBracket&&this.closingBracket.deepClone(),this.missingOpeningBracketIds)}computeMinIndentation(e,t){return this.child?this.child.computeMinIndentation((0,r.QB)(e,this.openingBracket.length),t):Number.MAX_SAFE_INTEGER}}class c extends a{static create23(e,t,i,s=!1){let n=e.length,o=e.missingOpeningBracketIds;if(e.listHeight!==t.listHeight)throw new Error("Invalid list heights");if(n=(0,r.QB)(n,t.length),o=o.merge(t.missingOpeningBracketIds),i){if(e.listHeight!==i.listHeight)throw new Error("Invalid list heights");n=(0,r.QB)(n,i.length),o=o.merge(i.missingOpeningBracketIds)}return s?new d(n,e.listHeight+1,e,t,i,o):new h(n,e.listHeight+1,e,t,i,o)}static getEmpty(){return new g(r.Vp,0,[],o.gV.getEmpty())}get kind(){return 4}get missingOpeningBracketIds(){return this._missingOpeningBracketIds}constructor(e,t,i){super(e),this.listHeight=t,this._missingOpeningBracketIds=i,this.cachedMinIndentation=-1}throwIfImmutable(){}makeLastElementMutable(){this.throwIfImmutable();const e=this.childrenLength;if(0===e)return;const t=this.getChild(e-1),i=4===t.kind?t.toMutable():t;return t!==i&&this.setChild(e-1,i),i}makeFirstElementMutable(){this.throwIfImmutable();if(0===this.childrenLength)return;const e=this.getChild(0),t=4===e.kind?e.toMutable():e;return e!==t&&this.setChild(0,t),t}canBeReused(e){if(e.intersects(this.missingOpeningBracketIds))return!1;if(0===this.childrenLength)return!1;let t=this;for(;4===t.kind;){const e=t.childrenLength;if(0===e)throw new s.D7;t=t.getChild(e-1)}return t.canBeReused(e)}handleChildrenChanged(){this.throwIfImmutable();const e=this.childrenLength;let t=this.getChild(0).length,i=this.getChild(0).missingOpeningBracketIds;for(let s=1;s{"use strict";i.d(t,{W:()=>o,c:()=>r});var s=i(36677),n=i(19131);class r{static fromModelContentChanges(e){return e.map((e=>{const t=s.Q.lift(e.range);return new r((0,n.VL)(t.getStartPosition()),(0,n.VL)(t.getEndPosition()),(0,n.rR)(e.text))})).reverse()}constructor(e,t,i){this.startOffset=e,this.endOffset=t,this.newLength=i}toString(){return`[${(0,n.l4)(this.startOffset)}...${(0,n.l4)(this.endOffset)}) -> ${(0,n.l4)(this.newLength)}`}}class o{constructor(e){this.nextEditIdx=0,this.deltaOldToNewLineCount=0,this.deltaOldToNewColumnCount=0,this.deltaLineIdxInOld=-1,this.edits=e.map((e=>a.from(e)))}getOffsetBeforeChange(e){return this.adjustNextEdit(e),this.translateCurToOld(e)}getDistanceToNextChange(e){this.adjustNextEdit(e);const t=this.edits[this.nextEditIdx],i=t?this.translateOldToCur(t.offsetObj):null;return null===i?null:(0,n.MS)(e,i)}translateOldToCur(e){return e.lineCount===this.deltaLineIdxInOld?(0,n.qe)(e.lineCount+this.deltaOldToNewLineCount,e.columnCount+this.deltaOldToNewColumnCount):(0,n.qe)(e.lineCount+this.deltaOldToNewLineCount,e.columnCount)}translateCurToOld(e){const t=(0,n.l4)(e);return t.lineCount-this.deltaOldToNewLineCount===this.deltaLineIdxInOld?(0,n.qe)(t.lineCount-this.deltaOldToNewLineCount,t.columnCount-this.deltaOldToNewColumnCount):(0,n.qe)(t.lineCount-this.deltaOldToNewLineCount,t.columnCount)}adjustNextEdit(e){for(;this.nextEditIdx{"use strict";i.d(t,{Z:()=>c});var s=i(91508),n=i(40579),r=i(19131),o=i(32956),a=i(51934);class l{static createFromLanguage(e,t){function i(e){return t.getKey(`${e.languageId}:::${e.bracketText}`)}const s=new Map;for(const l of e.bracketsNew.openingBrackets){const e=(0,r.qe)(0,l.bracketText.length),t=i(l),c=o.gV.getEmpty().add(t,o.FD);s.set(l.bracketText,new a.ou(e,1,t,c,n.rh.create(e,l,c)))}for(const l of e.bracketsNew.closingBrackets){const e=(0,r.qe)(0,l.bracketText.length);let t=o.gV.getEmpty();const c=l.getOpeningBrackets();for(const s of c)t=t.add(i(s),o.FD);s.set(l.bracketText,new a.ou(e,2,i(c[0]),t,n.rh.create(e,l,t)))}return new l(s)}constructor(e){this.map=e,this.hasRegExp=!1,this._regExpGlobal=null}getRegExpStr(){if(this.isEmpty)return null;{const e=[...this.map.keys()];return e.sort(),e.reverse(),e.map((e=>function(e){let t=(0,s.bm)(e);/^[\w ]+/.test(e)&&(t=`\\b${t}`);/[\w ]+$/.test(e)&&(t=`${t}\\b`);return t}(e))).join("|")}}get regExpGlobal(){if(!this.hasRegExp){const e=this.getRegExpStr();this._regExpGlobal=e?new RegExp(e,"gi"):null,this.hasRegExp=!0}return this._regExpGlobal}getToken(e){return this.map.get(e.toLowerCase())}findClosingTokenText(e){for(const[t,i]of this.map)if(2===i.kind&&i.bracketIds.intersects(e))return t}get isEmpty(){return 0===this.map.size}}class c{constructor(e,t){this.denseKeyProvider=e,this.getLanguageConfiguration=t,this.languageIdToBracketTokens=new Map}didLanguageChange(e){return this.languageIdToBracketTokens.has(e)}getSingleLanguageBracketTokens(e){let t=this.languageIdToBracketTokens.get(e);return t||(t=l.createFromLanguage(this.getLanguageConfiguration(e),this.denseKeyProvider),this.languageIdToBracketTokens.set(e,t)),t}}},84084:(e,t,i)=>{"use strict";i.d(t,{M:()=>o});var s=i(25890),n=i(94650),r=i(19131);function o(e,t){if(0===e.length)return t;if(0===t.length)return e;const i=new s.j3(l(e)),o=l(t);o.push({modified:!1,lengthBefore:void 0,lengthAfter:void 0});let c=i.dequeue();function h(e){if(void 0===e){const e=i.takeWhile((e=>!0))||[];return c&&e.unshift(c),e}const t=[];for(;c&&!(0,r.Vh)(e);){const[s,n]=c.splitAt(e);t.push(s),e=(0,r.MS)(s.lengthAfter,e),c=n??i.dequeue()}return(0,r.Vh)(e)||t.push(new a(!1,e,e)),t}const d=[];function u(e,t,i){if(d.length>0&&(0,r.wP)(d[d.length-1].endOffset,e)){const e=d[d.length-1];d[d.length-1]=new n.c(e.startOffset,t,(0,r.QB)(e.newLength,i))}else d.push({startOffset:e,endOffset:t,newLength:i})}let g=r.Vp;for(const s of o){const e=h(s.lengthBefore);if(s.modified){const t=(0,r.pW)(e,(e=>e.lengthBefore)),i=(0,r.QB)(g,t);u(g,i,s.lengthAfter),g=i}else for(const t of e){const e=g;g=(0,r.QB)(g,t.lengthBefore),t.modified&&u(e,g,t.lengthAfter)}}return d}class a{constructor(e,t,i){this.modified=e,this.lengthBefore=t,this.lengthAfter=i}splitAt(e){const t=(0,r.MS)(e,this.lengthAfter);return(0,r.wP)(t,r.Vp)?[this,void 0]:this.modified?[new a(this.modified,this.lengthBefore,e),new a(this.modified,r.Vp,t)]:[new a(this.modified,e,e),new a(this.modified,t,t)]}toString(){return`${this.modified?"M":"U"}:${(0,r.l4)(this.lengthBefore)} -> ${(0,r.l4)(this.lengthAfter)}`}}function l(e){const t=[];let i=r.Vp;for(const s of e){const e=(0,r.MS)(i,s.startOffset);(0,r.Vh)(e)||t.push(new a(!1,e,e));const n=(0,r.MS)(s.startOffset,s.endOffset);t.push(new a(!0,n,s.newLength)),i=s.endOffset}return t}},19131:(e,t,i)=>{"use strict";i.d(t,{C7:()=>o,MS:()=>_,QB:()=>p,Qx:()=>S,VL:()=>E,Vh:()=>l,Vp:()=>a,eu:()=>u,l4:()=>d,o0:()=>b,pW:()=>m,qe:()=>h,rR:()=>y,sS:()=>g,vr:()=>C,wP:()=>f,zG:()=>v});var s=i(91508),n=i(36677),r=i(50973);function o(e,t,i,s){return e!==i?h(i-e,s):h(0,s-t)}const a=0;function l(e){return 0===e}const c=2**26;function h(e,t){return e*c+t}function d(e){const t=e,i=Math.floor(t/c),s=t-i*c;return new r.W(i,s)}function u(e){return Math.floor(e/c)}function g(e){return e}function p(e,t){let i=e+t;return t>=c&&(i-=e%c),i}function m(e,t){return e.reduce(((e,i)=>p(e,t(i))),a)}function f(e,t){return e===t}function _(e,t){const i=e,s=t;if(s-i<=0)return a;const n=Math.floor(i/c),r=Math.floor(s/c),o=s-r*c;if(n===r){return h(0,o-(i-n*c))}return h(r-n,o)}function v(e,t){return e=t}function E(e){return h(e.lineNumber-1,e.column-1)}function S(e,t){const i=e,s=Math.floor(i/c),r=i-s*c,o=t,a=Math.floor(o/c),l=o-a*c;return new n.Q(s+1,r+1,a+1,l+1)}function y(e){const t=(0,s.uz)(e);return h(t.length-1,t[t.length-1].length)}},19562:(e,t,i)=>{"use strict";i.d(t,{T:()=>g});var s=i(40579),n=i(94650),r=i(32956),o=i(19131);function a(e,t=!1){if(0===e.length)return null;if(1===e.length)return e[0];let i=e.length;for(;i>3;){const n=i>>1;for(let r=0;r=3?e[2]:null,t)}function l(e,t){return Math.abs(e.listHeight-t.listHeight)}function c(e,t){return e.listHeight===t.listHeight?s.Xw.create23(e,t,null,!1):e.listHeight>t.listHeight?function(e,t){let i=e=e.toMutable();const n=[];let r;for(;;){if(t.listHeight===i.listHeight){r=t;break}if(4!==i.kind)throw new Error("unexpected");n.push(i),i=i.makeLastElementMutable()}for(let o=n.length-1;o>=0;o--){const e=n[o];r?e.childrenLength>=3?r=s.Xw.create23(e.unappendChild(),r,null,!1):(e.appendChildOfSameHeight(r),r=void 0):e.handleChildrenChanged()}return r?s.Xw.create23(e,r,null,!1):e}(e,t):function(e,t){let i=e=e.toMutable();const n=[];for(;t.listHeight!==i.listHeight;){if(4!==i.kind)throw new Error("unexpected");n.push(i),i=i.makeFirstElementMutable()}let r=t;for(let o=n.length-1;o>=0;o--){const e=n[o];r?e.childrenLength>=3?r=s.Xw.create23(r,e.unprependChild(),null,!1):(e.prependChildOfSameHeight(r),r=void 0):e.handleChildrenChanged()}return r?s.Xw.create23(r,e,null,!1):e}(t,e)}class h{constructor(e){this.lastOffset=o.Vp,this.nextNodes=[e],this.offsets=[o.Vp],this.idxs=[]}readLongestNodeAt(e,t){if((0,o.zG)(e,this.lastOffset))throw new Error("Invalid offset");for(this.lastOffset=e;;){const i=u(this.nextNodes);if(!i)return;const s=u(this.offsets);if((0,o.zG)(e,s))return;if((0,o.zG)(s,e))if((0,o.QB)(s,i.length)<=e)this.nextNodeAfterCurrent();else{const e=d(i);-1!==e?(this.nextNodes.push(i.getChild(e)),this.offsets.push(s),this.idxs.push(e)):this.nextNodeAfterCurrent()}else{if(t(i))return this.nextNodeAfterCurrent(),i;{const e=d(i);if(-1===e)return void this.nextNodeAfterCurrent();this.nextNodes.push(i.getChild(e)),this.offsets.push(s),this.idxs.push(e)}}}}nextNodeAfterCurrent(){for(;;){const e=u(this.offsets),t=u(this.nextNodes);if(this.nextNodes.pop(),this.offsets.pop(),0===this.idxs.length)break;const i=u(this.nextNodes),s=d(i,this.idxs[this.idxs.length-1]);if(-1!==s){this.nextNodes.push(i.getChild(s)),this.offsets.push((0,o.QB)(e,t.length)),this.idxs[this.idxs.length-1]=s;break}this.idxs.pop()}}}function d(e,t=-1){for(;;){if(++t>=e.childrenLength)return-1;if(e.getChild(t))return t}}function u(e){return e.length>0?e[e.length-1]:void 0}function g(e,t,i,s){return new p(e,t,i,s).parseDocument()}class p{constructor(e,t,i,s){if(this.tokenizer=e,this.createImmutableLists=s,this._itemsConstructed=0,this._itemsFromCache=0,i&&s)throw new Error("Not supported");this.oldNodeReader=i?new h(i):void 0,this.positionMapper=new n.W(t)}parseDocument(){this._itemsConstructed=0,this._itemsFromCache=0;let e=this.parseList(r.gV.getEmpty(),0);return e||(e=s.Xw.getEmpty()),e}parseList(e,t){const i=[];for(;;){let s=this.tryReadChildFromCache(e);if(!s){const i=this.tokenizer.peek();if(!i||2===i.kind&&i.bracketIds.intersects(e))break;s=this.parseChild(e,t+1)}4===s.kind&&0===s.childrenLength||i.push(s)}const s=this.oldNodeReader?function(e){if(0===e.length)return null;if(1===e.length)return e[0];let t=0;function i(){if(t>=e.length)return null;const i=t,s=e[i].listHeight;for(t++;t=2?a(0===i&&t===e.length?e:e.slice(i,t),!1):e[i]}let s=i(),n=i();if(!n)return s;for(let r=i();r;r=i())l(s,n)<=l(n,r)?(s=c(s,n),n=r):n=c(n,r);return c(s,n)}(i):a(i,this.createImmutableLists);return s}tryReadChildFromCache(e){if(this.oldNodeReader){const t=this.positionMapper.getDistanceToNextChange(this.tokenizer.offset);if(null===t||!(0,o.Vh)(t)){const i=this.oldNodeReader.readLongestNodeAt(this.positionMapper.getOffsetBeforeChange(this.tokenizer.offset),(i=>{if(null!==t&&!(0,o.zG)(i.length,t))return!1;return i.canBeReused(e)}));if(i)return this._itemsFromCache++,this.tokenizer.skip(i.length),i}}}parseChild(e,t){this._itemsConstructed++;const i=this.tokenizer.read();switch(i.kind){case 2:return new s.Gc(i.bracketIds,i.length);case 0:return i.astNode;case 1:{if(t>300)return new s.yF(i.length);const n=e.merge(i.bracketIds),r=this.parseList(n,t+1),o=this.tokenizer.peek();return o&&2===o.kind&&(o.bracketId===i.bracketId||o.bracketIds.intersects(i.bracketIds))?(this.tokenizer.read(),s.Nn.create(i.astNode,r,o.astNode)):s.Nn.create(i.astNode,r,null)}default:throw new Error("unexpected")}}}},32956:(e,t,i)=>{"use strict";i.d(t,{FD:()=>r,Mg:()=>o,gV:()=>n});const s=[];class n{static{this.cache=new Array(129)}static create(e,t){if(e<=128&&0===t.length){let i=n.cache[e];return i||(i=new n(e,t),n.cache[e]=i),i}return new n(e,t)}static{this.empty=n.create(0,s)}static getEmpty(){return this.empty}constructor(e,t){this.items=e,this.additionalItems=t}add(e,t){const i=t.getKey(e);let s=i>>5;if(0===s){const e=1<e};class o{constructor(){this.items=new Map}getKey(e){let t=this.items.get(e);return void 0===t&&(t=this.items.size,this.items.set(e,t)),t}}},51934:(e,t,i)=>{"use strict";i.d(t,{_:()=>d,ou:()=>l,tk:()=>c});var s=i(64383),n=i(25982),r=i(40579),o=i(19131),a=i(32956);class l{constructor(e,t,i,s,n){this.length=e,this.kind=t,this.bracketId=i,this.bracketIds=s,this.astNode=n}}class c{constructor(e,t){this.textModel=e,this.bracketTokens=t,this.reader=new h(this.textModel,this.bracketTokens),this._offset=o.Vp,this.didPeek=!1,this.peeked=null,this.textBufferLineCount=e.getLineCount(),this.textBufferLastLineLength=e.getLineLength(this.textBufferLineCount)}get offset(){return this._offset}get length(){return(0,o.qe)(this.textBufferLineCount-1,this.textBufferLastLineLength)}skip(e){this.didPeek=!1,this._offset=(0,o.QB)(this._offset,e);const t=(0,o.l4)(this._offset);this.reader.setPosition(t.lineCount,t.columnCount)}read(){let e;return this.peeked?(this.didPeek=!1,e=this.peeked):e=this.reader.read(),e&&(this._offset=(0,o.QB)(this._offset,e.length)),e}peek(){return this.didPeek||(this.peeked=this.reader.read(),this.didPeek=!0),this.peeked}}class h{constructor(e,t){this.textModel=e,this.bracketTokens=t,this.lineIdx=0,this.line=null,this.lineCharOffset=0,this.lineTokens=null,this.lineTokenOffset=0,this.peekedToken=null,this.textBufferLineCount=e.getLineCount(),this.textBufferLastLineLength=e.getLineLength(this.textBufferLineCount)}setPosition(e,t){e===this.lineIdx?(this.lineCharOffset=t,null!==this.line&&(this.lineTokenOffset=0===this.lineCharOffset?0:this.lineTokens.findTokenIndexAtOffset(this.lineCharOffset))):(this.lineIdx=e,this.lineCharOffset=t,this.line=null),this.peekedToken=null}read(){if(this.peekedToken){const e=this.peekedToken;return this.peekedToken=null,this.lineCharOffset+=(0,o.sS)(e.length),e}if(this.lineIdx>this.textBufferLineCount-1||this.lineIdx===this.textBufferLineCount-1&&this.lineCharOffset>=this.textBufferLastLineLength)return null;null===this.line&&(this.lineTokens=this.textModel.tokenization.getLineTokens(this.lineIdx+1),this.line=this.lineTokens.getLineContent(),this.lineTokenOffset=0===this.lineCharOffset?0:this.lineTokens.findTokenIndexAtOffset(this.lineCharOffset));const e=this.lineIdx,t=this.lineCharOffset;let i=0;for(;;){const s=this.lineTokens,r=s.getCount();let a=null;if(this.lineTokenOffset1e3)break}if(i>1500)break}const s=(0,o.C7)(e,t,this.lineIdx,this.lineCharOffset);return new l(s,0,-1,a.gV.getEmpty(),new r.yF(s))}}class d{constructor(e,t){this.text=e,this._offset=o.Vp,this.idx=0;const i=t.getRegExpStr(),s=i?new RegExp(i+"|\n","gi"):null,n=[];let c,h=0,d=0,u=0,g=0;const p=[];for(let _=0;_<60;_++)p.push(new l((0,o.qe)(0,_),0,-1,a.gV.getEmpty(),new r.yF((0,o.qe)(0,_))));const m=[];for(let _=0;_<60;_++)m.push(new l((0,o.qe)(1,_),0,-1,a.gV.getEmpty(),new r.yF((0,o.qe)(1,_))));if(s)for(s.lastIndex=0;null!==(c=s.exec(e));){const e=c.index,i=c[0];if("\n"===i)h++,d=e+1;else{if(u!==e){let t;if(g===h){const i=e-u;if(i{"use strict";i.d(t,{Th:()=>m,z8:()=>f});var s=i(78209),n=i(64383),r=i(75326),o=i(79400),a=i(64829),l=i(81674),c=i(89403);function h(e){return e.toString()}class d{static create(e,t){const i=e.getAlternativeVersionId(),s=p(e);return new d(i,i,s,s,t,t,[])}constructor(e,t,i,s,n,r,o){this.beforeVersionId=e,this.afterVersionId=t,this.beforeEOL=i,this.afterEOL=s,this.beforeCursorState=n,this.afterCursorState=r,this.changes=o}append(e,t,i,s,n){t.length>0&&(this.changes=(0,a.x)(this.changes,t)),this.afterEOL=i,this.afterVersionId=s,this.afterCursorState=n}static _writeSelectionsSize(e){return 4+16*(e?e.length:0)}static _writeSelections(e,t,i){if(l.Sw(e,t?t.length:0,i),i+=4,t)for(const s of t)l.Sw(e,s.selectionStartLineNumber,i),i+=4,l.Sw(e,s.selectionStartColumn,i),i+=4,l.Sw(e,s.positionLineNumber,i),i+=4,l.Sw(e,s.positionColumn,i),i+=4;return i}static _readSelections(e,t,i){const s=l.bb(e,t);t+=4;for(let n=0;ne.toString())).join(", ")}matchesResource(e){return(o.r.isUri(this.model)?this.model:this.model.uri).toString()===e.toString()}setModel(e){this.model=e}canAppend(e){return this.model===e&&this._data instanceof d}append(e,t,i,s,n){this._data instanceof d&&this._data.append(e,t,i,s,n)}close(){this._data instanceof d&&(this._data=this._data.serialize())}open(){this._data instanceof d||(this._data=d.deserialize(this._data))}undo(){if(o.r.isUri(this.model))throw new Error("Invalid SingleModelEditStackElement");this._data instanceof d&&(this._data=this._data.serialize());const e=d.deserialize(this._data);this.model._applyUndo(e.changes,e.beforeEOL,e.beforeVersionId,e.beforeCursorState)}redo(){if(o.r.isUri(this.model))throw new Error("Invalid SingleModelEditStackElement");this._data instanceof d&&(this._data=this._data.serialize());const e=d.deserialize(this._data);this.model._applyRedo(e.changes,e.afterEOL,e.afterVersionId,e.afterCursorState)}heapSize(){return this._data instanceof d&&(this._data=this._data.serialize()),this._data.byteLength+168}}class g{get resources(){return this._editStackElementsArr.map((e=>e.resource))}constructor(e,t,i){this.label=e,this.code=t,this.type=1,this._isOpen=!0,this._editStackElementsArr=i.slice(0),this._editStackElementsMap=new Map;for(const s of this._editStackElementsArr){const e=h(s.resource);this._editStackElementsMap.set(e,s)}this._delegate=null}prepareUndoRedo(){if(this._delegate)return this._delegate.prepareUndoRedo(this)}matchesResource(e){const t=h(e);return this._editStackElementsMap.has(t)}setModel(e){const t=h(o.r.isUri(e)?e:e.uri);this._editStackElementsMap.has(t)&&this._editStackElementsMap.get(t).setModel(e)}canAppend(e){if(!this._isOpen)return!1;const t=h(e.uri);if(this._editStackElementsMap.has(t)){return this._editStackElementsMap.get(t).canAppend(e)}return!1}append(e,t,i,s,n){const r=h(e.uri);this._editStackElementsMap.get(r).append(e,t,i,s,n)}close(){this._isOpen=!1}open(){}undo(){this._isOpen=!1;for(const e of this._editStackElementsArr)e.undo()}redo(){for(const e of this._editStackElementsArr)e.redo()}heapSize(e){const t=h(e);if(this._editStackElementsMap.has(t)){return this._editStackElementsMap.get(t).heapSize()}return 0}split(){return this._editStackElementsArr}toString(){const e=[];for(const t of this._editStackElementsArr)e.push(`${(0,c.P8)(t.resource)}: ${t}`);return`{${e.join(", ")}}`}}function p(e){return"\n"===e.getEOL()?0:1}function m(e){return!!e&&(e instanceof u||e instanceof g)}class f{constructor(e,t){this._model=e,this._undoRedoService=t}pushStackElement(){const e=this._undoRedoService.getLastElement(this._model.uri);m(e)&&e.close()}popStackElement(){const e=this._undoRedoService.getLastElement(this._model.uri);m(e)&&e.open()}clear(){this._undoRedoService.removeElements(this._model.uri)}_getOrCreateEditStackElement(e,t){const i=this._undoRedoService.getLastElement(this._model.uri);if(m(i)&&i.canAppend(this._model))return i;const n=new u(s.kg("edit","Typing"),"undoredo.textBufferEdit",this._model,e);return this._undoRedoService.pushElement(n,t),n}pushEOL(e){const t=this._getOrCreateEditStackElement(null,void 0);this._model.setEOL(e),t.append(this._model,[],p(this._model),this._model.getAlternativeVersionId(),null)}pushEditOperation(e,t,i,s){const n=this._getOrCreateEditStackElement(e,s),r=this._model.applyEdits(t,!0),o=f._computeCursorState(i,r),a=r.map(((e,t)=>({index:t,textChange:e.textChange})));return a.sort(((e,t)=>e.textChange.oldPosition===t.textChange.oldPosition?e.index-t.index:e.textChange.oldPosition-t.textChange.oldPosition)),n.append(this._model,a.map((e=>e.textChange)),p(this._model),this._model.getAlternativeVersionId(),o),o}static _computeCursorState(e,t){try{return e?e(t):null}catch(i){return(0,n.dz)(i),null}}}},53450:(e,t,i)=>{"use strict";i.d(t,{P:()=>d,k:()=>u});var s=i(46041),n=i(91508),r=i(1245),o=i(36677),a=i(20761),l=i(78049),c=i(84739),h=i(64383);class d extends a._{constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t}getLanguageConfiguration(e){return this.languageConfigurationService.getLanguageConfiguration(e)}_computeIndentLevel(e){return(0,l.G)(this.textModel.getLineContent(e+1),this.textModel.getOptions().tabSize)}getActiveIndentGuide(e,t,i){this.assertNotDisposed();const s=this.textModel.getLineCount();if(e<1||e>s)throw new h.D7("Illegal value for lineNumber");const n=this.getLanguageConfiguration(this.textModel.getLanguageId()).foldingRules,r=Boolean(n&&n.offSide);let o=-2,a=-1,l=-2,c=-1;const d=e=>{if(-1!==o&&(-2===o||o>e-1)){o=-1,a=-1;for(let t=e-2;t>=0;t--){const e=this._computeIndentLevel(t);if(e>=0){o=t,a=e;break}}}if(-2===l){l=-1,c=-1;for(let t=e;t=0){l=t,c=e;break}}}};let u=-2,g=-1,p=-2,m=-1;const f=e=>{if(-2===u){u=-1,g=-1;for(let t=e-2;t>=0;t--){const e=this._computeIndentLevel(t);if(e>=0){u=t,g=e;break}}}if(-1!==p&&(-2===p||p=0){p=t,m=e;break}}}};let _=0,v=!0,C=0,b=!0,E=0,S=0;for(let h=0;v||b;h++){const n=e-h,o=e+h;h>1&&(n<1||n1&&(o>s||o>i)&&(b=!1),h>5e4&&(v=!1,b=!1);let p=-1;if(v&&n>=1){const e=this._computeIndentLevel(n-1);e>=0?(l=n-1,c=e,p=Math.ceil(e/this.textModel.getOptions().indentSize)):(d(n),p=this._getIndentLevelForWhitespaceLine(r,a,c))}let y=-1;if(b&&o<=s){const e=this._computeIndentLevel(o-1);e>=0?(u=o-1,g=e,y=Math.ceil(e/this.textModel.getOptions().indentSize)):(f(o),y=this._getIndentLevelForWhitespaceLine(r,g,m))}if(0!==h){if(1===h){if(o<=s&&y>=0&&S+1===y){v=!1,_=o,C=o,E=y;continue}if(n>=1&&p>=0&&p-1===S){b=!1,_=n,C=n,E=p;continue}if(_=e,C=e,E=S,0===E)return{startLineNumber:_,endLineNumber:C,indent:E}}v&&(p>=E?_=n:v=!1),b&&(y>=E?C=o:b=!1)}else S=p}return{startLineNumber:_,endLineNumber:C,indent:E}}getLinesBracketGuides(e,t,i,r){const a=[];for(let s=e;s<=t;s++)a.push([]);const l=!0,h=this.textModel.bracketPairs.getBracketPairsInRangeWithMinIndentation(new o.Q(e,1,t,this.textModel.getLineMaxColumn(t))).toArray();let d;if(i&&h.length>0){const n=(e<=i.lineNumber&&i.lineNumber<=t?h:this.textModel.bracketPairs.getBracketPairsInRange(o.Q.fromPositions(i)).toArray()).filter((e=>o.Q.strictContainsPosition(e.range,i)));d=(0,s.Uk)(n,(e=>l))?.range}const g=this.textModel.getOptions().bracketPairColorizationOptions.independentColorPoolPerBracketType,p=new u;for(const s of h){if(!s.closingBracketRange)continue;const i=d&&s.range.equalsRange(d);if(!i&&!r.includeInactive)continue;const o=p.getInlineClassName(s.nestingLevel,s.nestingLevelOfEqualBracketType,g)+(r.highlightActive&&i?" "+p.activeClassName:""),l=s.openingBracketRange.getStartPosition(),h=s.closingBracketRange.getStartPosition(),u=r.horizontalGuides===c.N6.Enabled||r.horizontalGuides===c.N6.EnabledForActive&&i;if(s.range.startLineNumber===s.range.endLineNumber){u&&a[s.range.startLineNumber-e].push(new c.TH(-1,s.openingBracketRange.getEndPosition().column,o,new c.pv(!1,h.column),-1,-1));continue}const m=this.getVisibleColumnFromPosition(h),f=this.getVisibleColumnFromPosition(s.openingBracketRange.getStartPosition()),_=Math.min(f,m,s.minVisibleColumnIndentation+1);let v=!1;n.HG(this.textModel.getLineContent(s.closingBracketRange.startLineNumber))=e&&f>_&&a[l.lineNumber-e].push(new c.TH(_,-1,o,new c.pv(!1,l.column),-1,-1)),h.lineNumber<=t&&m>_&&a[h.lineNumber-e].push(new c.TH(_,-1,o,new c.pv(!v,h.column),-1,-1)))}for(const s of a)s.sort(((e,t)=>e.visibleColumn-t.visibleColumn));return a}getVisibleColumnFromPosition(e){return r.A.visibleColumnFromColumn(this.textModel.getLineContent(e.lineNumber),e.column,this.textModel.getOptions().tabSize)+1}getLinesIndentGuides(e,t){this.assertNotDisposed();const i=this.textModel.getLineCount();if(e<1||e>i)throw new Error("Illegal value for startLineNumber");if(t<1||t>i)throw new Error("Illegal value for endLineNumber");const s=this.textModel.getOptions(),n=this.getLanguageConfiguration(this.textModel.getLanguageId()).foldingRules,r=Boolean(n&&n.offSide),o=new Array(t-e+1);let a=-2,l=-1,c=-2,h=-1;for(let d=e;d<=t;d++){const t=d-e,n=this._computeIndentLevel(d-1);if(n>=0)a=d-1,l=n,o[t]=Math.ceil(n/s.indentSize);else{if(-2===a){a=-1,l=-1;for(let e=d-2;e>=0;e--){const t=this._computeIndentLevel(e);if(t>=0){a=e,l=t;break}}}if(-1!==c&&(-2===c||c=0){c=e,h=t;break}}}o[t]=this._getIndentLevelForWhitespaceLine(r,l,h)}}return o}_getIndentLevelForWhitespaceLine(e,t,i){const s=this.textModel.getOptions();return-1===t||-1===i?0:t{"use strict";i.d(t,{N:()=>r,c2:()=>o});var s=i(25890),n=i(85152);class r{constructor(e){this.values=e,this.prefixSum=new Uint32Array(e.length),this.prefixSumValidIndex=new Int32Array(1),this.prefixSumValidIndex[0]=-1}insertValues(e,t){e=(0,n.j)(e);const i=this.values,s=this.prefixSum,r=t.length;return 0!==r&&(this.values=new Uint32Array(i.length+r),this.values.set(i.subarray(0,e),0),this.values.set(i.subarray(e),e+r),this.values.set(t,e),e-1=0&&this.prefixSum.set(s.subarray(0,this.prefixSumValidIndex[0]+1)),!0)}setValue(e,t){return e=(0,n.j)(e),t=(0,n.j)(t),this.values[e]!==t&&(this.values[e]=t,e-1=i.length)return!1;const r=i.length-e;return t>=r&&(t=r),0!==t&&(this.values=new Uint32Array(i.length-t),this.values.set(i.subarray(0,e),0),this.values.set(i.subarray(e+t),e),this.prefixSum=new Uint32Array(this.values.length),e-1=0&&this.prefixSum.set(s.subarray(0,this.prefixSumValidIndex[0]+1)),!0)}getTotalSum(){return 0===this.values.length?0:this._getPrefixSum(this.values.length-1)}getPrefixSum(e){return e<0?0:(e=(0,n.j)(e),this._getPrefixSum(e))}_getPrefixSum(e){if(e<=this.prefixSumValidIndex[0])return this.prefixSum[e];let t=this.prefixSumValidIndex[0]+1;0===t&&(this.prefixSum[0]=this.values[0],t++),e>=this.values.length&&(e=this.values.length-1);for(let i=t;i<=e;i++)this.prefixSum[i]=this.prefixSum[i-1]+this.values[i];return this.prefixSumValidIndex[0]=Math.max(this.prefixSumValidIndex[0],e),this.prefixSum[e]}getIndexOf(e){e=Math.floor(e),this.getTotalSum();let t=0,i=this.values.length-1,s=0,n=0,r=0;for(;t<=i;)if(s=t+(i-t)/2|0,n=this.prefixSum[s],r=n-this.values[s],e=n))break;t=s+1}return new a(s,e-r)}}class o{constructor(e){this._values=e,this._isValid=!1,this._validEndIndex=-1,this._prefixSum=[],this._indexBySum=[]}getTotalSum(){return this._ensureValid(),this._indexBySum.length}getPrefixSum(e){return this._ensureValid(),0===e?0:this._prefixSum[e-1]}getIndexOf(e){this._ensureValid();const t=this._indexBySum[e],i=t>0?this._prefixSum[t-1]:0;return new a(t,e-i)}removeValues(e,t){this._values.splice(e,t),this._invalidate(e)}insertValues(e,t){this._values=(0,s.nK)(this._values,e,t),this._invalidate(e)}_invalidate(e){this._isValid=!1,this._validEndIndex=Math.min(this._validEndIndex,e-1)}_ensureValid(){if(!this._isValid){for(let e=this._validEndIndex+1,t=this._values.length;e0?this._prefixSum[e-1]:0;this._prefixSum[e]=i+t;for(let s=0;s{"use strict";i.d(t,{Ho:()=>Qt,kI:()=>Xt,Bz:()=>Wt});var s=i(25890),n=i(47661),r=i(64383),o=i(41234),a=i(5662),l=i(91508),c=i(79400),h=i(64454),d=i(93895),u=i(83069),g=i(36677),p=i(75326),m=i(24329),f=i(10154),_=i(17469),v=i(16223),C=i(12296),b=i(56772);class E{constructor(e,t,i,s){this.range=e,this.nestingLevel=t,this.nestingLevelOfEqualBracketType=i,this.isInvalid=s}}class S{constructor(e,t,i,s,n,r){this.range=e,this.openingBracketRange=t,this.closingBracketRange=i,this.nestingLevel=s,this.nestingLevelOfEqualBracketType=n,this.bracketPairNode=r}get openingBracketInfo(){return this.bracketPairNode.openingBracket.bracketInfo}}class y extends S{constructor(e,t,i,s,n,r,o){super(e,t,i,s,n,r),this.minVisibleColumnIndentation=o}}var w=i(94650),L=i(93630),R=i(19131),T=i(19562),x=i(32956),k=i(51934),A=i(84084);class N extends a.jG{didLanguageChange(e){return this.brackets.didLanguageChange(e)}constructor(e,t){if(super(),this.textModel=e,this.getLanguageConfiguration=t,this.didChangeEmitter=new o.vl,this.denseKeyProvider=new x.Mg,this.brackets=new L.Z(this.denseKeyProvider,this.getLanguageConfiguration),this.onDidChange=this.didChangeEmitter.event,this.queuedTextEditsForInitialAstWithoutTokens=[],this.queuedTextEdits=[],e.tokenization.hasTokens)2===e.tokenization.backgroundTokenizationState?(this.initialAstWithoutTokens=void 0,this.astWithTokens=this.parseDocumentFromTextBuffer([],void 0,!1)):(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer([],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens);else{const e=this.brackets.getSingleLanguageBracketTokens(this.textModel.getLanguageId()),t=new k._(this.textModel.getValue(),e);this.initialAstWithoutTokens=(0,T.T)(t,[],void 0,!0),this.astWithTokens=this.initialAstWithoutTokens}}handleDidChangeBackgroundTokenizationState(){if(2===this.textModel.tokenization.backgroundTokenizationState){const e=void 0===this.initialAstWithoutTokens;this.initialAstWithoutTokens=void 0,e||this.didChangeEmitter.fire()}}handleDidChangeTokens({ranges:e}){const t=e.map((e=>new w.c((0,R.qe)(e.fromLineNumber-1,0),(0,R.qe)(e.toLineNumber,0),(0,R.qe)(e.toLineNumber-e.fromLineNumber+1,0))));this.handleEdits(t,!0),this.initialAstWithoutTokens||this.didChangeEmitter.fire()}handleContentChanged(e){const t=w.c.fromModelContentChanges(e.changes);this.handleEdits(t,!1)}handleEdits(e,t){const i=(0,A.M)(this.queuedTextEdits,e);this.queuedTextEdits=i,this.initialAstWithoutTokens&&!t&&(this.queuedTextEditsForInitialAstWithoutTokens=(0,A.M)(this.queuedTextEditsForInitialAstWithoutTokens,e))}flushQueue(){this.queuedTextEdits.length>0&&(this.astWithTokens=this.parseDocumentFromTextBuffer(this.queuedTextEdits,this.astWithTokens,!1),this.queuedTextEdits=[]),this.queuedTextEditsForInitialAstWithoutTokens.length>0&&(this.initialAstWithoutTokens&&(this.initialAstWithoutTokens=this.parseDocumentFromTextBuffer(this.queuedTextEditsForInitialAstWithoutTokens,this.initialAstWithoutTokens,!1)),this.queuedTextEditsForInitialAstWithoutTokens=[])}parseDocumentFromTextBuffer(e,t,i){const s=t,n=new k.tk(this.textModel,this.brackets);return(0,T.T)(n,e,s,i)}getBracketsInRange(e,t){this.flushQueue();const i=(0,R.qe)(e.startLineNumber-1,e.startColumn-1),n=(0,R.qe)(e.endLineNumber-1,e.endColumn-1);return new s.c1((e=>{const s=this.initialAstWithoutTokens||this.astWithTokens;D(s,R.Vp,s.length,i,n,e,0,0,new Map,t)}))}getBracketPairsInRange(e,t){this.flushQueue();const i=(0,R.VL)(e.getStartPosition()),n=(0,R.VL)(e.getEndPosition());return new s.c1((e=>{const s=this.initialAstWithoutTokens||this.astWithTokens,r=new M(e,t,this.textModel);P(s,R.Vp,s.length,i,n,r,0,new Map)}))}getFirstBracketAfter(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return O(t,R.Vp,t.length,(0,R.VL)(e))}getFirstBracketBefore(e){this.flushQueue();const t=this.initialAstWithoutTokens||this.astWithTokens;return I(t,R.Vp,t.length,(0,R.VL)(e))}}function I(e,t,i,s){if(4===e.kind||2===e.kind){const n=[];for(const s of e.children)i=(0,R.QB)(t,s.length),n.push({nodeOffsetStart:t,nodeOffsetEnd:i}),t=i;for(let t=n.length-1;t>=0;t--){const{nodeOffsetStart:i,nodeOffsetEnd:r}=n[t];if((0,R.zG)(i,s)){const n=I(e.children[t],i,r,s);if(n)return n}}return null}if(3===e.kind)return null;if(1===e.kind){const s=(0,R.Qx)(t,i);return{bracketInfo:e.bracketInfo,range:s}}return null}function O(e,t,i,s){if(4===e.kind||2===e.kind){for(const n of e.children){if(i=(0,R.QB)(t,n.length),(0,R.zG)(s,i)){const e=O(n,t,i,s);if(e)return e}t=i}return null}if(3===e.kind)return null;if(1===e.kind){const s=(0,R.Qx)(t,i);return{bracketInfo:e.bracketInfo,range:s}}return null}function D(e,t,i,s,n,r,o,a,l,c,h=!1){if(o>200)return!0;e:for(;;)switch(e.kind){case 4:{const a=e.childrenLength;for(let h=0;h200)return!0;let l=!0;if(2===e.kind){let c=0;if(a){let t=a.get(e.openingBracket.text);void 0===t&&(t=0),c=t,t++,a.set(e.openingBracket.text,t)}const h=(0,R.QB)(t,e.openingBracket.length);let d=-1;if(r.includeMinIndentation&&(d=e.computeMinIndentation(t,r.textModel)),l=r.push(new y((0,R.Qx)(t,i),(0,R.Qx)(t,h),e.closingBracket?(0,R.Qx)((0,R.QB)(h,e.child?.length||R.Vp),i):void 0,o,c,e,d)),t=h,l&&e.child){const c=e.child;if(i=(0,R.QB)(t,c.length),(0,R.vr)(t,n)&&(0,R.o0)(i,s)&&(l=P(c,t,i,s,n,r,o+1,a),!l))return!1}a?.set(e.openingBracket.text,c)}else{let i=t;for(const t of e.children){const e=i;if(i=(0,R.QB)(i,t.length),(0,R.vr)(e,n)&&(0,R.vr)(s,i)&&(l=P(t,e,i,s,n,r,o,a),!l))return!1}}return l}class F extends a.jG{get canBuildAST(){return this.textModel.getValueLength()<=5e6}constructor(e,t){super(),this.textModel=e,this.languageConfigurationService=t,this.bracketPairsTree=this._register(new a.HE),this.onDidChangeEmitter=new o.vl,this.onDidChange=this.onDidChangeEmitter.event,this.bracketsRequested=!1}handleLanguageConfigurationServiceChange(e){e.languageId&&!this.bracketPairsTree.value?.object.didLanguageChange(e.languageId)||(this.bracketPairsTree.clear(),this.updateBracketPairsTree())}handleDidChangeOptions(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeLanguage(e){this.bracketPairsTree.clear(),this.updateBracketPairsTree()}handleDidChangeContent(e){this.bracketPairsTree.value?.object.handleContentChanged(e)}handleDidChangeBackgroundTokenizationState(){this.bracketPairsTree.value?.object.handleDidChangeBackgroundTokenizationState()}handleDidChangeTokens(e){this.bracketPairsTree.value?.object.handleDidChangeTokens(e)}updateBracketPairsTree(){if(this.bracketsRequested&&this.canBuildAST){if(!this.bracketPairsTree.value){const i=new a.Cm;this.bracketPairsTree.value=(e=i.add(new N(this.textModel,(e=>this.languageConfigurationService.getLanguageConfiguration(e)))),t=i,{object:e,dispose:()=>t?.dispose()}),i.add(this.bracketPairsTree.value.object.onDidChange((e=>this.onDidChangeEmitter.fire(e)))),this.onDidChangeEmitter.fire()}}else this.bracketPairsTree.value&&(this.bracketPairsTree.clear(),this.onDidChangeEmitter.fire());var e,t}getBracketPairsInRange(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!1)||s.c1.empty}getBracketPairsInRangeWithMinIndentation(e){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketPairsInRange(e,!0)||s.c1.empty}getBracketsInRange(e,t=!1){return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getBracketsInRange(e,t)||s.c1.empty}findMatchingBracketUp(e,t,i){const s=this.textModel.validatePosition(t),n=this.textModel.getLanguageIdAtPosition(s.lineNumber,s.column);if(this.canBuildAST){const i=this.languageConfigurationService.getLanguageConfiguration(n).bracketsNew.getClosingBracketInfo(e);if(!i)return null;const s=this.getBracketPairsInRange(g.Q.fromPositions(t,t)).findLast((e=>i.closes(e.openingBracketInfo)));return s?s.openingBracketRange:null}{const t=e.toLowerCase(),r=this.languageConfigurationService.getLanguageConfiguration(n).brackets;if(!r)return null;const o=r.textIsBracket[t];return o?B(this._findMatchingBracketUp(o,s,U(i))):null}}matchBracket(e,t){if(this.canBuildAST){const t=this.getBracketPairsInRange(g.Q.fromPositions(e,e)).filter((t=>void 0!==t.closingBracketRange&&(t.openingBracketRange.containsPosition(e)||t.closingBracketRange.containsPosition(e)))).findLastMaxBy((0,s.VE)((t=>t.openingBracketRange.containsPosition(e)?t.openingBracketRange:t.closingBracketRange),g.Q.compareRangesUsingStarts));return t?[t.openingBracketRange,t.closingBracketRange]:null}{const i=U(t);return this._matchBracket(this.textModel.validatePosition(e),i)}}_establishBracketSearchOffsets(e,t,i,s){const n=t.getCount(),r=t.getLanguageId(s);let o=Math.max(0,e.column-1-i.maxBracketLength);for(let l=s-1;l>=0;l--){const e=t.getEndOffset(l);if(e<=o)break;if((0,C.Yo)(t.getStandardTokenType(l))||t.getLanguageId(l)!==r){o=e;break}}let a=Math.min(t.getLineContent().length,e.column-1+i.maxBracketLength);for(let l=s+1;l=a)break;if((0,C.Yo)(t.getStandardTokenType(l))||t.getLanguageId(l)!==r){a=e;break}}return{searchStartOffset:o,searchEndOffset:a}}_matchBracket(e,t){const i=e.lineNumber,s=this.textModel.tokenization.getLineTokens(i),n=this.textModel.getLineContent(i),r=s.findTokenIndexAtOffset(e.column-1);if(r<0)return null;const o=this.languageConfigurationService.getLanguageConfiguration(s.getLanguageId(r)).brackets;if(o&&!(0,C.Yo)(s.getStandardTokenType(r))){let{searchStartOffset:a,searchEndOffset:l}=this._establishBracketSearchOffsets(e,s,o,r),c=null;for(;;){const s=b.Fu.findNextBracketInRange(o.forwardRegex,i,n,a,l);if(!s)break;if(s.startColumn<=e.column&&e.column<=s.endColumn){const e=n.substring(s.startColumn-1,s.endColumn-1).toLowerCase(),i=this._matchFoundBracket(s,o.textIsBracket[e],o.textIsOpenBracket[e],t);if(i){if(i instanceof H)return null;c=i}}a=s.endColumn-1}if(c)return c}if(r>0&&s.getStartOffset(r)===e.column-1){const o=r-1,a=this.languageConfigurationService.getLanguageConfiguration(s.getLanguageId(o)).brackets;if(a&&!(0,C.Yo)(s.getStandardTokenType(o))){const{searchStartOffset:r,searchEndOffset:l}=this._establishBracketSearchOffsets(e,s,a,o),c=b.Fu.findPrevBracketInRange(a.reversedRegex,i,n,r,l);if(c&&c.startColumn<=e.column&&e.column<=c.endColumn){const e=n.substring(c.startColumn-1,c.endColumn-1).toLowerCase(),i=this._matchFoundBracket(c,a.textIsBracket[e],a.textIsOpenBracket[e],t);if(i)return i instanceof H?null:i}}}return null}_matchFoundBracket(e,t,i,s){if(!t)return null;const n=i?this._findMatchingBracketDown(t,e.getEndPosition(),s):this._findMatchingBracketUp(t,e.getStartPosition(),s);return n?n instanceof H?n:[e,n]:null}_findMatchingBracketUp(e,t,i){const s=e.languageId,n=e.reversedRegex;let r=-1,o=0;const a=(t,s,a,l)=>{for(;;){if(i&&++o%100===0&&!i())return H.INSTANCE;const c=b.Fu.findPrevBracketInRange(n,t,s,a,l);if(!c)break;const h=s.substring(c.startColumn-1,c.endColumn-1).toLowerCase();if(e.isOpen(h)?r++:e.isClose(h)&&r--,0===r)return c;l=c.startColumn-1}return null};for(let l=t.lineNumber;l>=1;l--){const e=this.textModel.tokenization.getLineTokens(l),i=e.getCount(),n=this.textModel.getLineContent(l);let r=i-1,o=n.length,c=n.length;l===t.lineNumber&&(r=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,c=t.column-1);let h=!0;for(;r>=0;r--){const t=e.getLanguageId(r)===s&&!(0,C.Yo)(e.getStandardTokenType(r));if(t)h?o=e.getStartOffset(r):(o=e.getStartOffset(r),c=e.getEndOffset(r));else if(h&&o!==c){const e=a(l,n,o,c);if(e)return e}h=t}if(h&&o!==c){const e=a(l,n,o,c);if(e)return e}}return null}_findMatchingBracketDown(e,t,i){const s=e.languageId,n=e.forwardRegex;let r=1,o=0;const a=(t,s,a,l)=>{for(;;){if(i&&++o%100===0&&!i())return H.INSTANCE;const c=b.Fu.findNextBracketInRange(n,t,s,a,l);if(!c)break;const h=s.substring(c.startColumn-1,c.endColumn-1).toLowerCase();if(e.isOpen(h)?r++:e.isClose(h)&&r--,0===r)return c;a=c.endColumn-1}return null},l=this.textModel.getLineCount();for(let c=t.lineNumber;c<=l;c++){const e=this.textModel.tokenization.getLineTokens(c),i=e.getCount(),n=this.textModel.getLineContent(c);let r=0,o=0,l=0;c===t.lineNumber&&(r=e.findTokenIndexAtOffset(t.column-1),o=t.column-1,l=t.column-1);let h=!0;for(;r=1;r--){const e=this.textModel.tokenization.getLineTokens(r),o=e.getCount(),a=this.textModel.getLineContent(r);let l=o-1,c=a.length,h=a.length;if(r===t.lineNumber){l=e.findTokenIndexAtOffset(t.column-1),c=t.column-1,h=t.column-1;const r=e.getLanguageId(l);i!==r&&(i=r,s=this.languageConfigurationService.getLanguageConfiguration(i).brackets,n=this.languageConfigurationService.getLanguageConfiguration(i).bracketsNew)}let d=!0;for(;l>=0;l--){const t=e.getLanguageId(l);if(i!==t){if(s&&n&&d&&c!==h){const e=b.Fu.findPrevBracketInRange(s.reversedRegex,r,a,c,h);if(e)return this._toFoundBracket(n,e);d=!1}i=t,s=this.languageConfigurationService.getLanguageConfiguration(i).brackets,n=this.languageConfigurationService.getLanguageConfiguration(i).bracketsNew}const o=!!s&&!(0,C.Yo)(e.getStandardTokenType(l));if(o)d?c=e.getStartOffset(l):(c=e.getStartOffset(l),h=e.getEndOffset(l));else if(n&&s&&d&&c!==h){const e=b.Fu.findPrevBracketInRange(s.reversedRegex,r,a,c,h);if(e)return this._toFoundBracket(n,e)}d=o}if(n&&s&&d&&c!==h){const e=b.Fu.findPrevBracketInRange(s.reversedRegex,r,a,c,h);if(e)return this._toFoundBracket(n,e)}}return null}findNextBracket(e){const t=this.textModel.validatePosition(e);if(this.canBuildAST)return this.bracketsRequested=!0,this.updateBracketPairsTree(),this.bracketPairsTree.value?.object.getFirstBracketAfter(t)||null;const i=this.textModel.getLineCount();let s=null,n=null,r=null;for(let o=t.lineNumber;o<=i;o++){const e=this.textModel.tokenization.getLineTokens(o),i=e.getCount(),a=this.textModel.getLineContent(o);let l=0,c=0,h=0;if(o===t.lineNumber){l=e.findTokenIndexAtOffset(t.column-1),c=t.column-1,h=t.column-1;const i=e.getLanguageId(l);s!==i&&(s=i,n=this.languageConfigurationService.getLanguageConfiguration(s).brackets,r=this.languageConfigurationService.getLanguageConfiguration(s).bracketsNew)}let d=!0;for(;lvoid 0!==t.closingBracketRange&&t.range.strictContainsRange(e)));return t?[t.openingBracketRange,t.closingBracketRange]:null}const s=U(t),n=this.textModel.getLineCount(),r=new Map;let o=[];const a=(e,t)=>{if(!r.has(e)){const i=[];for(let e=0,s=t?t.brackets.length:0;e{for(;;){if(s&&++l%100===0&&!s())return H.INSTANCE;const a=b.Fu.findNextBracketInRange(e.forwardRegex,t,i,n,r);if(!a)break;const c=i.substring(a.startColumn-1,a.endColumn-1).toLowerCase(),h=e.textIsBracket[c];if(h&&(h.isOpen(c)?o[h.index]++:h.isClose(c)&&o[h.index]--,-1===o[h.index]))return this._matchFoundBracket(a,h,!1,s);n=a.endColumn-1}return null};let h=null,d=null;for(let u=i.lineNumber;u<=n;u++){const e=this.textModel.tokenization.getLineTokens(u),t=e.getCount(),s=this.textModel.getLineContent(u);let n=0,r=0,o=0;if(u===i.lineNumber){n=e.findTokenIndexAtOffset(i.column-1),r=i.column-1,o=i.column-1;const t=e.getLanguageId(n);h!==t&&(h=t,d=this.languageConfigurationService.getLanguageConfiguration(h).brackets,a(h,d))}let l=!0;for(;n!0;{const t=Date.now();return()=>Date.now()-t<=e}}class H{static{this.INSTANCE=new H}constructor(){this._searchCanceledBrand=void 0}}function B(e){return e instanceof H?null:e}var W=i(87119),V=i(47612);class z extends a.jG{constructor(e){super(),this.textModel=e,this.colorProvider=new G,this.onDidChangeEmitter=new o.vl,this.onDidChange=this.onDidChangeEmitter.event,this.colorizationOptions=e.getOptions().bracketPairColorizationOptions,this._register(e.bracketPairs.onDidChange((e=>{this.onDidChangeEmitter.fire()})))}handleDidChangeOptions(e){this.colorizationOptions=this.textModel.getOptions().bracketPairColorizationOptions}getDecorationsInRange(e,t,i,s){if(s)return[];if(void 0===t)return[];if(!this.colorizationOptions.enabled)return[];return this.textModel.bracketPairs.getBracketsInRange(e,!0).map((e=>({id:`bracket${e.range.toString()}-${e.nestingLevel}`,options:{description:"BracketPairColorization",inlineClassName:this.colorProvider.getInlineClassName(e,this.colorizationOptions.independentColorPoolPerBracketType)},ownerId:0,range:e.range}))).toArray()}getAllDecorations(e,t){return void 0===e?[]:this.colorizationOptions.enabled?this.getDecorationsInRange(new g.Q(1,1,this.textModel.getLineCount(),1),e,t):[]}}class G{constructor(){this.unexpectedClosingBracketClassName="unexpected-closing-bracket"}getInlineClassName(e,t){return e.isInvalid?this.unexpectedClosingBracketClassName:this.getInlineClassNameOfLevel(t?e.nestingLevelOfEqualBracketType:e.nestingLevel)}getInlineClassNameOfLevel(e){return"bracket-highlighting-"+e%30}}(0,V.zy)(((e,t)=>{const i=[W.sN,W.lQ,W.ss,W.l5,W.sH,W.zp],s=new G;t.addRule(`.monaco-editor .${s.unexpectedClosingBracketClassName} { color: ${e.getColor(W.s7)}; }`);const n=i.map((t=>e.getColor(t))).filter((e=>!!e)).filter((e=>!e.isTransparent()));for(let r=0;r<30;r++){const e=n[r%n.length];t.addRule(`.monaco-editor .${s.getInlineClassNameOfLevel(r)} { color: ${e}; }`)}}));var j=i(26656),K=i(53450);class Y{constructor(){this.spacesDiff=0,this.looksLikeAlignment=!1}}function q(e,t,i,s,n){let r;for(n.spacesDiff=0,n.looksLikeAlignment=!1,r=0;r0&&a>0)return;if(l>0&&c>0)return;const h=Math.abs(a-c),d=Math.abs(o-l);if(0===h)return n.spacesDiff=d,void(d>0&&0<=l-1&&l-10?n++:m>1&&r++,q(o,a,l,p,h),h.looksLikeAlignment&&(!i||t!==h.spacesDiff))continue;const _=h.spacesDiff;_<=8&&c[_]++,o=l,a=p}let d=i;n!==r&&(d=n{const i=c[t];i>e&&(e=i,u=t)})),4===u&&c[4]>0&&c[2]>0&&c[2]>=c[4]/2&&(u=2)}return{insertSpaces:d,tabSize:u}}function Q(e){return(1&e.metadata)>>>0}function X(e,t){e.metadata=254&e.metadata|t}function Z(e){return(2&e.metadata)>>>1===1}function J(e,t){e.metadata=253&e.metadata|(t?1:0)<<1}function ee(e){return(4&e.metadata)>>>2===1}function te(e,t){e.metadata=251&e.metadata|(t?1:0)<<2}function ie(e){return(64&e.metadata)>>>6===1}function se(e,t){e.metadata=191&e.metadata|(t?1:0)<<6}function ne(e,t){e.metadata=231&e.metadata|t<<3}function re(e,t){e.metadata=223&e.metadata|(t?1:0)<<5}class oe{constructor(e,t,i){this.metadata=0,this.parent=this,this.left=this,this.right=this,X(this,1),this.start=t,this.end=i,this.delta=0,this.maxEnd=i,this.id=e,this.ownerId=0,this.options=null,te(this,!1),se(this,!1),ne(this,1),re(this,!1),this.cachedVersionId=0,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=i,this.range=null,J(this,!1)}reset(e,t,i,s){this.start=t,this.end=i,this.maxEnd=i,this.cachedVersionId=e,this.cachedAbsoluteStart=t,this.cachedAbsoluteEnd=i,this.range=s}setOptions(e){this.options=e;const t=this.options.className;te(this,"squiggly-error"===t||"squiggly-warning"===t||"squiggly-info"===t),se(this,null!==this.options.glyphMarginClassName),ne(this,this.options.stickiness),re(this,this.options.collapseOnReplaceEdit)}setCachedOffsets(e,t,i){this.cachedVersionId!==i&&(this.range=null),this.cachedVersionId=i,this.cachedAbsoluteStart=e,this.cachedAbsoluteEnd=t}detach(){this.parent=null,this.left=null,this.right=null}}const ae=new oe(null,0,0);ae.parent=ae,ae.left=ae,ae.right=ae,X(ae,0);class le{constructor(){this.root=ae,this.requestNormalizeDelta=!1}intervalSearch(e,t,i,s,n,r){return this.root===ae?[]:function(e,t,i,s,n,r,o){let a=e.root,l=0,c=0,h=0,d=0;const u=[];let g=0;for(;a!==ae;)if(Z(a))J(a.left,!1),J(a.right,!1),a===a.parent.right&&(l-=a.parent.delta),a=a.parent;else{if(!Z(a.left)){if(c=l+a.maxEnd,ci)J(a,!0);else{if(d=l+a.end,d>=t){a.setCachedOffsets(h,d,r);let e=!0;s&&a.ownerId&&a.ownerId!==s&&(e=!1),n&&ee(a)&&(e=!1),o&&!ie(a)&&(e=!1),e&&(u[g++]=a)}J(a,!0),a.right===ae||Z(a.right)||(l+=a.delta,a=a.right)}}return J(e.root,!1),u}(this,e,t,i,s,n,r)}search(e,t,i,s){return this.root===ae?[]:function(e,t,i,s,n){let r=e.root,o=0,a=0,l=0;const c=[];let h=0;for(;r!==ae;){if(Z(r)){J(r.left,!1),J(r.right,!1),r===r.parent.right&&(o-=r.parent.delta),r=r.parent;continue}if(r.left!==ae&&!Z(r.left)){r=r.left;continue}a=o+r.start,l=o+r.end,r.setCachedOffsets(a,l,s);let e=!0;t&&r.ownerId&&r.ownerId!==t&&(e=!1),i&&ee(r)&&(e=!1),n&&!ie(r)&&(e=!1),e&&(c[h++]=r),J(r,!0),r.right===ae||Z(r.right)||(o+=r.delta,r=r.right)}return J(e.root,!1),c}(this,e,t,i,s)}collectNodesFromOwner(e){return function(e,t){let i=e.root;const s=[];let n=0;for(;i!==ae;)Z(i)?(J(i.left,!1),J(i.right,!1),i=i.parent):i.left===ae||Z(i.left)?(i.ownerId===t&&(s[n++]=i),J(i,!0),i.right===ae||Z(i.right)||(i=i.right)):i=i.left;return J(e.root,!1),s}(this,e)}collectNodesPostOrder(){return function(e){let t=e.root;const i=[];let s=0;for(;t!==ae;)Z(t)?(J(t.left,!1),J(t.right,!1),t=t.parent):t.left===ae||Z(t.left)?t.right===ae||Z(t.right)?(i[s++]=t,J(t,!0)):t=t.right:t=t.left;return J(e.root,!1),i}(this)}insert(e){de(this,e),this._normalizeDeltaIfNecessary()}delete(e){ue(this,e),this._normalizeDeltaIfNecessary()}resolveNode(e,t){const i=e;let s=0;for(;e!==this.root;)e===e.parent.right&&(s+=e.parent.delta),e=e.parent;const n=i.start+s,r=i.end+s;i.setCachedOffsets(n,r,t)}acceptReplace(e,t,i,s){const n=function(e,t,i){let s=e.root,n=0,r=0,o=0,a=0;const l=[];let c=0;for(;s!==ae;)if(Z(s))J(s.left,!1),J(s.right,!1),s===s.parent.right&&(n-=s.parent.delta),s=s.parent;else{if(!Z(s.left)){if(r=n+s.maxEnd,ri?J(s,!0):(a=n+s.end,a>=t&&(s.setCachedOffsets(o,a,0),l[c++]=s),J(s,!0),s.right===ae||Z(s.right)||(n+=s.delta,s=s.right))}return J(e.root,!1),l}(this,e,e+t);for(let r=0,o=n.length;ri?(n.start+=l,n.end+=l,n.delta+=l,(n.delta<-1073741824||n.delta>1073741824)&&(e.requestNormalizeDelta=!0),J(n,!0)):(J(n,!0),n.right===ae||Z(n.right)||(r+=n.delta,n=n.right))}J(e.root,!1)}(this,e,e+t,i),this._normalizeDeltaIfNecessary();for(let r=0,o=n.length;ri)&&(1!==s&&(2===s||t))}function he(e,t,i,s,n){const r=function(e){return(24&e.metadata)>>>3}(e),o=0===r||2===r,a=1===r||2===r,l=i-t,c=s,h=Math.min(l,c),d=e.start;let u=!1;const g=e.end;let p=!1;t<=d&&g<=i&&function(e){return(32&e.metadata)>>>5===1}(e)&&(e.start=t,u=!0,e.end=t,p=!0);{const e=n?1:l>0?2:0;!u&&ce(d,o,t,e)&&(u=!0),!p&&ce(g,a,t,e)&&(p=!0)}if(h>0&&!n){const e=l>c?2:0;!u&&ce(d,o,t+h,e)&&(u=!0),!p&&ce(g,a,t+h,e)&&(p=!0)}{const s=n?1:0;!u&&ce(d,o,i,s)&&(e.start=t+c,u=!0),!p&&ce(g,a,i,s)&&(e.end=t+c,p=!0)}const m=c-l;u||(e.start=Math.max(0,d+m)),p||(e.end=Math.max(0,g+m)),e.start>e.end&&(e.end=e.start)}function de(e,t){if(e.root===ae)return t.parent=ae,t.left=ae,t.right=ae,X(t,0),e.root=t,e.root;!function(e,t){let i=0,s=e.root;const n=t.start,r=t.end;for(;;){if(Ce(n,r,s.start+i,s.end+i)<0){if(s.left===ae){t.start-=i,t.end-=i,t.maxEnd-=i,s.left=t;break}s=s.left}else{if(s.right===ae){t.start-=i+s.delta,t.end-=i+s.delta,t.maxEnd-=i+s.delta,s.right=t;break}i+=s.delta,s=s.right}}t.parent=s,t.left=ae,t.right=ae,X(t,1)}(e,t),ve(t.parent);let i=t;for(;i!==e.root&&1===Q(i.parent);)if(i.parent===i.parent.parent.left){const t=i.parent.parent.right;1===Q(t)?(X(i.parent,0),X(t,0),X(i.parent.parent,1),i=i.parent.parent):(i===i.parent.right&&(i=i.parent,pe(e,i)),X(i.parent,0),X(i.parent.parent,1),me(e,i.parent.parent))}else{const t=i.parent.parent.left;1===Q(t)?(X(i.parent,0),X(t,0),X(i.parent.parent,1),i=i.parent.parent):(i===i.parent.left&&(i=i.parent,me(e,i)),X(i.parent,0),X(i.parent.parent,1),pe(e,i.parent.parent))}return X(e.root,0),t}function ue(e,t){let i,s;if(t.left===ae?(i=t.right,s=t,i.delta+=t.delta,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),i.start+=t.delta,i.end+=t.delta):t.right===ae?(i=t.left,s=t):(s=function(e){for(;e.left!==ae;)e=e.left;return e}(t.right),i=s.right,i.start+=s.delta,i.end+=s.delta,i.delta+=s.delta,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),s.start+=t.delta,s.end+=t.delta,s.delta=t.delta,(s.delta<-1073741824||s.delta>1073741824)&&(e.requestNormalizeDelta=!0)),s===e.root)return e.root=i,X(i,0),t.detach(),ge(),_e(i),void(e.root.parent=ae);const n=1===Q(s);if(s===s.parent.left?s.parent.left=i:s.parent.right=i,s===t?i.parent=s.parent:(s.parent===t?i.parent=s:i.parent=s.parent,s.left=t.left,s.right=t.right,s.parent=t.parent,X(s,Q(t)),t===e.root?e.root=s:t===t.parent.left?t.parent.left=s:t.parent.right=s,s.left!==ae&&(s.left.parent=s),s.right!==ae&&(s.right.parent=s)),t.detach(),n)return ve(i.parent),s!==t&&(ve(s),ve(s.parent)),void ge();let r;for(ve(i),ve(i.parent),s!==t&&(ve(s),ve(s.parent));i!==e.root&&0===Q(i);)i===i.parent.left?(r=i.parent.right,1===Q(r)&&(X(r,0),X(i.parent,1),pe(e,i.parent),r=i.parent.right),0===Q(r.left)&&0===Q(r.right)?(X(r,1),i=i.parent):(0===Q(r.right)&&(X(r.left,0),X(r,1),me(e,r),r=i.parent.right),X(r,Q(i.parent)),X(i.parent,0),X(r.right,0),pe(e,i.parent),i=e.root)):(r=i.parent.left,1===Q(r)&&(X(r,0),X(i.parent,1),me(e,i.parent),r=i.parent.left),0===Q(r.left)&&0===Q(r.right)?(X(r,1),i=i.parent):(0===Q(r.left)&&(X(r.right,0),X(r,1),pe(e,r),r=i.parent.left),X(r,Q(i.parent)),X(i.parent,0),X(r.left,0),me(e,i.parent),i=e.root));X(i,0),ge()}function ge(){ae.parent=ae,ae.delta=0,ae.start=0,ae.end=0}function pe(e,t){const i=t.right;i.delta+=t.delta,(i.delta<-1073741824||i.delta>1073741824)&&(e.requestNormalizeDelta=!0),i.start+=t.delta,i.end+=t.delta,t.right=i.left,i.left!==ae&&(i.left.parent=t),i.parent=t.parent,t.parent===ae?e.root=i:t===t.parent.left?t.parent.left=i:t.parent.right=i,i.left=t,t.parent=i,_e(t),_e(i)}function me(e,t){const i=t.left;t.delta-=i.delta,(t.delta<-1073741824||t.delta>1073741824)&&(e.requestNormalizeDelta=!0),t.start-=i.delta,t.end-=i.delta,t.left=i.right,i.right!==ae&&(i.right.parent=t),i.parent=t.parent,t.parent===ae?e.root=i:t===t.parent.right?t.parent.right=i:t.parent.left=i,i.right=t,t.parent=i,_e(t),_e(i)}function fe(e){let t=e.end;if(e.left!==ae){const i=e.left.maxEnd;i>t&&(t=i)}if(e.right!==ae){const i=e.right.maxEnd+e.delta;i>t&&(t=i)}return t}function _e(e){e.maxEnd=fe(e)}function ve(e){for(;e!==ae;){const t=fe(e);if(e.maxEnd===t)return;e.maxEnd=t,e=e.parent}}function Ce(e,t,i,s){return e===i?t-s:e-i}class be{constructor(e,t){this.piece=e,this.color=t,this.size_left=0,this.lf_left=0,this.parent=this,this.left=this,this.right=this}next(){if(this.right!==Ee)return Se(this.right);let e=this;for(;e.parent!==Ee&&e.parent.left!==e;)e=e.parent;return e.parent===Ee?Ee:e.parent}prev(){if(this.left!==Ee)return ye(this.left);let e=this;for(;e.parent!==Ee&&e.parent.right!==e;)e=e.parent;return e.parent===Ee?Ee:e.parent}detach(){this.parent=null,this.left=null,this.right=null}}const Ee=new be(null,0);function Se(e){for(;e.left!==Ee;)e=e.left;return e}function ye(e){for(;e.right!==Ee;)e=e.right;return e}function we(e){return e===Ee?0:e.size_left+e.piece.length+we(e.right)}function Le(e){return e===Ee?0:e.lf_left+e.piece.lineFeedCnt+Le(e.right)}function Re(){Ee.parent=Ee}function Te(e,t){const i=t.right;i.size_left+=t.size_left+(t.piece?t.piece.length:0),i.lf_left+=t.lf_left+(t.piece?t.piece.lineFeedCnt:0),t.right=i.left,i.left!==Ee&&(i.left.parent=t),i.parent=t.parent,t.parent===Ee?e.root=i:t.parent.left===t?t.parent.left=i:t.parent.right=i,i.left=t,t.parent=i}function xe(e,t){const i=t.left;t.left=i.right,i.right!==Ee&&(i.right.parent=t),i.parent=t.parent,t.size_left-=i.size_left+(i.piece?i.piece.length:0),t.lf_left-=i.lf_left+(i.piece?i.piece.lineFeedCnt:0),t.parent===Ee?e.root=i:t===t.parent.right?t.parent.right=i:t.parent.left=i,i.right=t,t.parent=i}function ke(e,t){let i,s;if(t.left===Ee?(s=t,i=s.right):t.right===Ee?(s=t,i=s.left):(s=Se(t.right),i=s.right),s===e.root)return e.root=i,i.color=0,t.detach(),Re(),void(e.root.parent=Ee);const n=1===s.color;if(s===s.parent.left?s.parent.left=i:s.parent.right=i,s===t?(i.parent=s.parent,Ie(e,i)):(s.parent===t?i.parent=s:i.parent=s.parent,Ie(e,i),s.left=t.left,s.right=t.right,s.parent=t.parent,s.color=t.color,t===e.root?e.root=s:t===t.parent.left?t.parent.left=s:t.parent.right=s,s.left!==Ee&&(s.left.parent=s),s.right!==Ee&&(s.right.parent=s),s.size_left=t.size_left,s.lf_left=t.lf_left,Ie(e,s)),t.detach(),i.parent.left===i){const t=we(i),s=Le(i);if(t!==i.parent.size_left||s!==i.parent.lf_left){const n=t-i.parent.size_left,r=s-i.parent.lf_left;i.parent.size_left=t,i.parent.lf_left=s,Ne(e,i.parent,n,r)}}if(Ie(e,i.parent),n)return void Re();let r;for(;i!==e.root&&0===i.color;)i===i.parent.left?(r=i.parent.right,1===r.color&&(r.color=0,i.parent.color=1,Te(e,i.parent),r=i.parent.right),0===r.left.color&&0===r.right.color?(r.color=1,i=i.parent):(0===r.right.color&&(r.left.color=0,r.color=1,xe(e,r),r=i.parent.right),r.color=i.parent.color,i.parent.color=0,r.right.color=0,Te(e,i.parent),i=e.root)):(r=i.parent.left,1===r.color&&(r.color=0,i.parent.color=1,xe(e,i.parent),r=i.parent.left),0===r.left.color&&0===r.right.color?(r.color=1,i=i.parent):(0===r.left.color&&(r.right.color=0,r.color=1,Te(e,r),r=i.parent.left),r.color=i.parent.color,i.parent.color=0,r.left.color=0,xe(e,i.parent),i=e.root));i.color=0,Re()}function Ae(e,t){for(Ie(e,t);t!==e.root&&1===t.parent.color;)if(t.parent===t.parent.parent.left){const i=t.parent.parent.right;1===i.color?(t.parent.color=0,i.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.right&&Te(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,xe(e,t.parent.parent))}else{const i=t.parent.parent.left;1===i.color?(t.parent.color=0,i.color=0,t.parent.parent.color=1,t=t.parent.parent):(t===t.parent.left&&xe(e,t=t.parent),t.parent.color=0,t.parent.parent.color=1,Te(e,t.parent.parent))}e.root.color=0}function Ne(e,t,i,s){for(;t!==e.root&&t!==Ee;)t.parent.left===t&&(t.parent.size_left+=i,t.parent.lf_left+=s),t=t.parent}function Ie(e,t){let i=0,s=0;if(t!==e.root){for(;t!==e.root&&t===t.parent.right;)t=t.parent;if(t!==e.root)for(i=we((t=t.parent).left)-t.size_left,s=Le(t.left)-t.lf_left,t.size_left+=i,t.lf_left+=s;t!==e.root&&(0!==i||0!==s);)t.parent.left===t&&(t.parent.size_left+=i,t.parent.lf_left+=s),t=t.parent}}Ee.parent=Ee,Ee.left=Ee,Ee.right=Ee,Ee.color=0;var Oe=i(43264);const De=65535;function Me(e){let t;return t=e[e.length-1]<65536?new Uint16Array(e.length):new Uint32Array(e.length),t.set(e,0),t}class Pe{constructor(e,t,i,s,n){this.lineStarts=e,this.cr=t,this.lf=i,this.crlf=s,this.isBasicASCII=n}}function Fe(e,t=!0){const i=[0];let s=1;for(let n=0,r=e.length;n(e!==Ee&&this._pieces.push(e.piece),!0)))}read(){return 0===this._pieces.length?0===this._index?(this._index++,this._BOM):null:this._index>this._pieces.length-1?null:0===this._index?this._BOM+this._tree.getPieceContent(this._pieces[this._index++]):this._tree.getPieceContent(this._pieces[this._index++])}}class We{constructor(e){this._limit=e,this._cache=[]}get(e){for(let t=this._cache.length-1;t>=0;t--){const i=this._cache[t];if(i.nodeStartOffset<=e&&i.nodeStartOffset+i.node.piece.length>=e)return i}return null}get2(e){for(let t=this._cache.length-1;t>=0;t--){const i=this._cache[t];if(i.nodeStartLineNumber&&i.nodeStartLineNumber=e)return i}return null}set(e){this._cache.length>=this._limit&&this._cache.shift(),this._cache.push(e)}validate(e){let t=!1;const i=this._cache;for(let s=0;s=e)&&(i[s]=null,t=!0)}if(t){const e=[];for(const t of i)null!==t&&e.push(t);this._cache=e}}}class Ve{constructor(e,t,i){this.create(e,t,i)}create(e,t,i){this._buffers=[new He("",[0])],this._lastChangeBufferPos={line:0,column:0},this.root=Ee,this._lineCnt=1,this._length=0,this._EOL=t,this._EOLLength=t.length,this._EOLNormalized=i;let s=null;for(let n=0,r=e.length;n0){e[n].lineStarts||(e[n].lineStarts=Fe(e[n].buffer));const t=new Ue(n+1,{line:0,column:0},{line:e[n].lineStarts.length-1,column:e[n].buffer.length-e[n].lineStarts[e[n].lineStarts.length-1]},e[n].lineStarts.length-1,e[n].buffer.length);this._buffers.push(e[n]),s=this.rbInsertRight(s,t)}this._searchCache=new We(1),this._lastVisitedLine={lineNumber:0,value:""},this.computeBufferMetadata()}normalizeEOL(e){const t=De,i=t-Math.floor(21845),s=2*i;let n="",r=0;const o=[];if(this.iterate(this.root,(t=>{const a=this.getNodeContent(t),l=a.length;if(r<=i||r+l0){const t=n.replace(/\r\n|\r|\n/g,e);o.push(new He(t,Fe(t)))}this.create(o,e,!0)}getEOL(){return this._EOL}setEOL(e){this._EOL=e,this._EOLLength=this._EOL.length,this.normalizeEOL(e)}createSnapshot(e){return new Be(this,e)}getOffsetAt(e,t){let i=0,s=this.root;for(;s!==Ee;)if(s.left!==Ee&&s.lf_left+1>=e)s=s.left;else{if(s.lf_left+s.piece.lineFeedCnt+1>=e){i+=s.size_left;return i+(this.getAccumulatedValue(s,e-s.lf_left-2)+t-1)}e-=s.lf_left+s.piece.lineFeedCnt,i+=s.size_left+s.piece.length,s=s.right}return i}getPositionAt(e){e=Math.floor(e),e=Math.max(0,e);let t=this.root,i=0;const s=e;for(;t!==Ee;)if(0!==t.size_left&&t.size_left>=e)t=t.left;else{if(t.size_left+t.piece.length>=e){const n=this.getIndexOf(t,e-t.size_left);if(i+=t.lf_left+n.index,0===n.index){const e=s-this.getOffsetAt(i+1,1);return new u.y(i+1,e+1)}return new u.y(i+1,n.remainder+1)}if(e-=t.size_left+t.piece.length,i+=t.lf_left+t.piece.lineFeedCnt,t.right===Ee){const t=s-e-this.getOffsetAt(i+1,1);return new u.y(i+1,t+1)}t=t.right}return new u.y(1,1)}getValueInRange(e,t){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return"";const i=this.nodeAt2(e.startLineNumber,e.startColumn),s=this.nodeAt2(e.endLineNumber,e.endColumn),n=this.getValueInRange2(i,s);return t?t===this._EOL&&this._EOLNormalized&&t===this.getEOL()&&this._EOLNormalized?n:n.replace(/\r\n|\r|\n/g,t):n}getValueInRange2(e,t){if(e.node===t.node){const i=e.node,s=this._buffers[i.piece.bufferIndex].buffer,n=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);return s.substring(n+e.remainder,n+t.remainder)}let i=e.node;const s=this._buffers[i.piece.bufferIndex].buffer,n=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);let r=s.substring(n+e.remainder,n+i.piece.length);for(i=i.next();i!==Ee;){const e=this._buffers[i.piece.bufferIndex].buffer,s=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);if(i===t.node){r+=e.substring(s,s+t.remainder);break}r+=e.substr(s,i.piece.length),i=i.next()}return r}getLinesContent(){const e=[];let t=0,i="",s=!1;return this.iterate(this.root,(n=>{if(n===Ee)return!0;const r=n.piece;let o=r.length;if(0===o)return!0;const a=this._buffers[r.bufferIndex].buffer,l=this._buffers[r.bufferIndex].lineStarts,c=r.start.line,h=r.end.line;let d=l[c]+r.start.column;if(s&&(10===a.charCodeAt(d)&&(d++,o--),e[t++]=i,i="",s=!1,0===o))return!0;if(c===h)return this._EOLNormalized||13!==a.charCodeAt(d+o-1)?i+=a.substr(d,o):(s=!0,i+=a.substr(d,o-1)),!0;i+=this._EOLNormalized?a.substring(d,Math.max(d,l[c+1]-this._EOLLength)):a.substring(d,l[c+1]).replace(/(\r\n|\r|\n)$/,""),e[t++]=i;for(let s=c+1;se+p,t.reset(0)):(v=d.buffer,C=e=>e,t.reset(p));do{if(f=t.next(v),f){if(C(f.index)>=m)return c;this.positionInBuffer(e,C(f.index)-u,_);const t=this.getLineFeedCnt(e.piece.bufferIndex,n,_),r=_.line===n.line?_.column-n.column+s:_.column+1,o=r+f[0].length;if(h[c++]=(0,Oe.dr)(new g.Q(i+t,r,i+t,o),f,a),C(f.index)+f[0].length>=m)return c;if(c>=l)return c}}while(f);return c}findMatchesLineByLine(e,t,i,s){const n=[];let r=0;const o=new Oe.W5(t.wordSeparators,t.regex);let a=this.nodeAt2(e.startLineNumber,e.startColumn);if(null===a)return[];const l=this.nodeAt2(e.endLineNumber,e.endColumn);if(null===l)return[];let c=this.positionInBuffer(a.node,a.remainder);const h=this.positionInBuffer(l.node,l.remainder);if(a.node===l.node)return this.findMatchesInNode(a.node,o,e.startLineNumber,e.startColumn,c,h,t,i,s,r,n),n;let d=e.startLineNumber,u=a.node;for(;u!==l.node;){const l=this.getLineFeedCnt(u.piece.bufferIndex,c,u.piece.end);if(l>=1){const a=this._buffers[u.piece.bufferIndex].lineStarts,h=this.offsetInBuffer(u.piece.bufferIndex,u.piece.start),g=a[c.line+l],p=d===e.startLineNumber?e.startColumn:1;if(r=this.findMatchesInNode(u,o,d,p,c,this.positionInBuffer(u,g-h),t,i,s,r,n),r>=s)return n;d+=l}const h=d===e.startLineNumber?e.startColumn-1:0;if(d===e.endLineNumber){const a=this.getLineContent(d).substring(h,e.endColumn-1);return r=this._findMatchesInLine(t,o,a,e.endLineNumber,h,r,n,i,s),n}if(r=this._findMatchesInLine(t,o,this.getLineContent(d).substr(h),d,h,r,n,i,s),r>=s)return n;d++,a=this.nodeAt2(d,1),u=a.node,c=this.positionInBuffer(a.node,a.remainder)}if(d===e.endLineNumber){const a=d===e.startLineNumber?e.startColumn-1:0,l=this.getLineContent(d).substring(a,e.endColumn-1);return r=this._findMatchesInLine(t,o,l,e.endLineNumber,a,r,n,i,s),n}const g=d===e.startLineNumber?e.startColumn:1;return r=this.findMatchesInNode(l.node,o,d,g,c,h,t,i,s,r,n),n}_findMatchesInLine(e,t,i,s,n,r,o,a,l){const c=e.wordSeparators;if(!a&&e.simpleSearch){const t=e.simpleSearch,a=t.length,h=i.length;let d=-a;for(;-1!==(d=i.indexOf(t,d+a));)if((!c||(0,Oe.wC)(c,i,h,d,a))&&(o[r++]=new v.Dg(new g.Q(s,d+1+n,s,d+1+a+n),null),r>=l))return r;return r}let h;t.reset(0);do{if(h=t.next(i),h&&(o[r++]=(0,Oe.dr)(new g.Q(s,h.index+1+n,s,h.index+1+h[0].length+n),h,a),r>=l))return r}while(h);return r}insert(e,t,i=!1){if(this._EOLNormalized=this._EOLNormalized&&i,this._lastVisitedLine.lineNumber=0,this._lastVisitedLine.value="",this.root!==Ee){const{node:i,remainder:s,nodeStartOffset:n}=this.nodeAt(e),r=i.piece,o=r.bufferIndex,a=this.positionInBuffer(i,s);if(0===i.piece.bufferIndex&&r.end.line===this._lastChangeBufferPos.line&&r.end.column===this._lastChangeBufferPos.column&&n+r.length===e&&t.lengthe){const e=[];let n=new Ue(r.bufferIndex,a,r.end,this.getLineFeedCnt(r.bufferIndex,a,r.end),this.offsetInBuffer(o,r.end)-this.offsetInBuffer(o,a));if(this.shouldCheckCRLF()&&this.endWithCR(t)){if(10===this.nodeCharCodeAt(i,s)){const e={line:n.start.line+1,column:0};n=new Ue(n.bufferIndex,e,n.end,this.getLineFeedCnt(n.bufferIndex,e,n.end),n.length-1),t+="\n"}}if(this.shouldCheckCRLF()&&this.startWithLF(t)){if(13===this.nodeCharCodeAt(i,s-1)){const n=this.positionInBuffer(i,s-1);this.deleteNodeTail(i,n),t="\r"+t,0===i.piece.length&&e.push(i)}else this.deleteNodeTail(i,a)}else this.deleteNodeTail(i,a);const l=this.createNewPieces(t);n.length>0&&this.rbInsertRight(i,n);let c=i;for(let t=0;t=0;r--)n=this.rbInsertLeft(n,s[r]);this.validateCRLFWithPrevNode(n),this.deleteNodes(i)}insertContentToNodeRight(e,t){this.adjustCarriageReturnFromNext(e,t)&&(e+="\n");const i=this.createNewPieces(e),s=this.rbInsertRight(t,i[0]);let n=s;for(let r=1;r=h))break;a=c+1}return i?(i.line=c,i.column=o-d,null):{line:c,column:o-d}}getLineFeedCnt(e,t,i){if(0===i.column)return i.line-t.line;const s=this._buffers[e].lineStarts;if(i.line===s.length-1)return i.line-t.line;const n=s[i.line+1],r=s[i.line]+i.column;if(n>r+1)return i.line-t.line;const o=r-1;return 13===this._buffers[e].buffer.charCodeAt(o)?i.line-t.line+1:i.line-t.line}offsetInBuffer(e,t){return this._buffers[e].lineStarts[t.line]+t.column}deleteNodes(e){for(let t=0;tDe){const t=[];for(;e.length>De;){const i=e.charCodeAt(65534);let s;13===i||i>=55296&&i<=56319?(s=e.substring(0,65534),e=e.substring(65534)):(s=e.substring(0,De),e=e.substring(De));const n=Fe(s);t.push(new Ue(this._buffers.length,{line:0,column:0},{line:n.length-1,column:s.length-n[n.length-1]},n.length-1,s.length)),this._buffers.push(new He(s,n))}const i=Fe(e);return t.push(new Ue(this._buffers.length,{line:0,column:0},{line:i.length-1,column:e.length-i[i.length-1]},i.length-1,e.length)),this._buffers.push(new He(e,i)),t}let t=this._buffers[0].buffer.length;const i=Fe(e,!1);let s=this._lastChangeBufferPos;if(this._buffers[0].lineStarts[this._buffers[0].lineStarts.length-1]===t&&0!==t&&this.startWithLF(e)&&this.endWithCR(this._buffers[0].buffer)){this._lastChangeBufferPos={line:this._lastChangeBufferPos.line,column:this._lastChangeBufferPos.column+1},s=this._lastChangeBufferPos;for(let e=0;e=e-1)i=i.left;else{if(i.lf_left+i.piece.lineFeedCnt>e-1){const s=this.getAccumulatedValue(i,e-i.lf_left-2),o=this.getAccumulatedValue(i,e-i.lf_left-1),a=this._buffers[i.piece.bufferIndex].buffer,l=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);return n+=i.size_left,this._searchCache.set({node:i,nodeStartOffset:n,nodeStartLineNumber:r-(e-1-i.lf_left)}),a.substring(l+s,l+o-t)}if(i.lf_left+i.piece.lineFeedCnt===e-1){const t=this.getAccumulatedValue(i,e-i.lf_left-2),n=this._buffers[i.piece.bufferIndex].buffer,r=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);s=n.substring(r+t,r+i.piece.length);break}e-=i.lf_left+i.piece.lineFeedCnt,n+=i.size_left+i.piece.length,i=i.right}}for(i=i.next();i!==Ee;){const e=this._buffers[i.piece.bufferIndex].buffer;if(i.piece.lineFeedCnt>0){const n=this.getAccumulatedValue(i,0),r=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);return s+=e.substring(r,r+n-t),s}{const t=this.offsetInBuffer(i.piece.bufferIndex,i.piece.start);s+=e.substr(t,i.piece.length)}i=i.next()}return s}computeBufferMetadata(){let e=this.root,t=1,i=0;for(;e!==Ee;)t+=e.lf_left+e.piece.lineFeedCnt,i+=e.size_left+e.piece.length,e=e.right;this._lineCnt=t,this._length=i,this._searchCache.validate(this._length)}getIndexOf(e,t){const i=e.piece,s=this.positionInBuffer(e,t),n=s.line-i.start.line;if(this.offsetInBuffer(i.bufferIndex,i.end)-this.offsetInBuffer(i.bufferIndex,i.start)===t){const t=this.getLineFeedCnt(e.piece.bufferIndex,i.start,s);if(t!==n)return{index:t,remainder:0}}return{index:n,remainder:s.column}}getAccumulatedValue(e,t){if(t<0)return 0;const i=e.piece,s=this._buffers[i.bufferIndex].lineStarts,n=i.start.line+t+1;return n>i.end.line?s[i.end.line]+i.end.column-s[i.start.line]-i.start.column:s[n]-s[i.start.line]-i.start.column}deleteNodeTail(e,t){const i=e.piece,s=i.lineFeedCnt,n=this.offsetInBuffer(i.bufferIndex,i.end),r=t,o=this.offsetInBuffer(i.bufferIndex,r),a=this.getLineFeedCnt(i.bufferIndex,i.start,r),l=a-s,c=o-n,h=i.length+c;e.piece=new Ue(i.bufferIndex,i.start,r,a,h),Ne(this,e,c,l)}deleteNodeHead(e,t){const i=e.piece,s=i.lineFeedCnt,n=this.offsetInBuffer(i.bufferIndex,i.start),r=t,o=this.getLineFeedCnt(i.bufferIndex,r,i.end),a=o-s,l=n-this.offsetInBuffer(i.bufferIndex,r),c=i.length+l;e.piece=new Ue(i.bufferIndex,r,i.end,o,c),Ne(this,e,l,a)}shrinkNode(e,t,i){const s=e.piece,n=s.start,r=s.end,o=s.length,a=s.lineFeedCnt,l=t,c=this.getLineFeedCnt(s.bufferIndex,s.start,l),h=this.offsetInBuffer(s.bufferIndex,t)-this.offsetInBuffer(s.bufferIndex,n);e.piece=new Ue(s.bufferIndex,s.start,l,c,h),Ne(this,e,h-o,c-a);const d=new Ue(s.bufferIndex,i,r,this.getLineFeedCnt(s.bufferIndex,i,r),this.offsetInBuffer(s.bufferIndex,r)-this.offsetInBuffer(s.bufferIndex,i)),u=this.rbInsertRight(e,d);this.validateCRLFWithPrevNode(u)}appendToNode(e,t){this.adjustCarriageReturnFromNext(t,e)&&(t+="\n");const i=this.shouldCheckCRLF()&&this.startWithLF(t)&&this.endWithCR(e),s=this._buffers[0].buffer.length;this._buffers[0].buffer+=t;const n=Fe(t,!1);for(let d=0;de)t=t.left;else{if(t.size_left+t.piece.length>=e){s+=t.size_left;const i={node:t,remainder:e-t.size_left,nodeStartOffset:s};return this._searchCache.set(i),i}e-=t.size_left+t.piece.length,s+=t.size_left+t.piece.length,t=t.right}return null}nodeAt2(e,t){let i=this.root,s=0;for(;i!==Ee;)if(i.left!==Ee&&i.lf_left>=e-1)i=i.left;else{if(i.lf_left+i.piece.lineFeedCnt>e-1){const n=this.getAccumulatedValue(i,e-i.lf_left-2),r=this.getAccumulatedValue(i,e-i.lf_left-1);return s+=i.size_left,{node:i,remainder:Math.min(n+t-1,r),nodeStartOffset:s}}if(i.lf_left+i.piece.lineFeedCnt===e-1){const n=this.getAccumulatedValue(i,e-i.lf_left-2);if(n+t-1<=i.piece.length)return{node:i,remainder:n+t-1,nodeStartOffset:s};t-=i.piece.length-n;break}e-=i.lf_left+i.piece.lineFeedCnt,s+=i.size_left+i.piece.length,i=i.right}for(i=i.next();i!==Ee;){if(i.piece.lineFeedCnt>0){const e=this.getAccumulatedValue(i,0),s=this.offsetOfNode(i);return{node:i,remainder:Math.min(t-1,e),nodeStartOffset:s}}if(i.piece.length>=t-1){return{node:i,remainder:t-1,nodeStartOffset:this.offsetOfNode(i)}}t-=i.piece.length,i=i.next()}return null}nodeCharCodeAt(e,t){if(e.piece.lineFeedCnt<1)return-1;const i=this._buffers[e.piece.bufferIndex],s=this.offsetInBuffer(e.piece.bufferIndex,e.piece.start)+t;return i.buffer.charCodeAt(s)}offsetOfNode(e){if(!e)return 0;let t=e.size_left;for(;e!==this.root;)e.parent.right===e&&(t+=e.parent.size_left+e.parent.piece.length),e=e.parent;return t}shouldCheckCRLF(){return!(this._EOLNormalized&&"\n"===this._EOL)}startWithLF(e){if("string"===typeof e)return 10===e.charCodeAt(0);if(e===Ee||0===e.piece.lineFeedCnt)return!1;const t=e.piece,i=this._buffers[t.bufferIndex].lineStarts,s=t.start.line,n=i[s]+t.start.column;if(s===i.length-1)return!1;return!(i[s+1]>n+1)&&10===this._buffers[t.bufferIndex].buffer.charCodeAt(n)}endWithCR(e){return"string"===typeof e?13===e.charCodeAt(e.length-1):e!==Ee&&0!==e.piece.lineFeedCnt&&13===this.nodeCharCodeAt(e,e.piece.length-1)}validateCRLFWithPrevNode(e){if(this.shouldCheckCRLF()&&this.startWithLF(e)){const t=e.prev();this.endWithCR(t)&&this.fixCRLF(t,e)}}validateCRLFWithNextNode(e){if(this.shouldCheckCRLF()&&this.endWithCR(e)){const t=e.next();this.startWithLF(t)&&this.fixCRLF(e,t)}}fixCRLF(e,t){const i=[],s=this._buffers[e.piece.bufferIndex].lineStarts;let n;n=0===e.piece.end.column?{line:e.piece.end.line-1,column:s[e.piece.end.line]-s[e.piece.end.line-1]-1}:{line:e.piece.end.line,column:e.piece.end.column-1};const r=e.piece.length-1,o=e.piece.lineFeedCnt-1;e.piece=new Ue(e.piece.bufferIndex,e.piece.start,n,o,r),Ne(this,e,-1,-1),0===e.piece.length&&i.push(e);const a={line:t.piece.start.line+1,column:0},l=t.piece.length-1,c=this.getLineFeedCnt(t.piece.bufferIndex,a,t.piece.end);t.piece=new Ue(t.piece.bufferIndex,a,t.piece.end,c,l),Ne(this,t,-1,-1),0===t.piece.length&&i.push(t);const h=this.createNewPieces("\r\n");this.rbInsertRight(e,h[0]);for(let d=0;de.sortIndex-t.sortIndex))}this._mightContainRTL=s,this._mightContainUnusualLineTerminators=n,this._mightContainNonBasicASCII=r;const p=this._doApplyEdits(a);let m=null;if(t&&u.length>0){u.sort(((e,t)=>t.lineNumber-e.lineNumber)),m=[];for(let e=0,t=u.length;e0&&u[e-1].lineNumber===t)continue;const i=u[e].oldContent,s=this.getLineContent(t);0!==s.length&&s!==i&&-1===l.HG(s)&&m.push(t)}}return this._onDidChangeContent.fire(),new v.F4(g,p,m)}_reduceOperations(e){return e.length<1e3?e:[this._toSingleEditOperation(e)]}_toSingleEditOperation(e){let t=!1;const i=e[0].range,s=e[e.length-1].range,n=new g.Q(i.startLineNumber,i.startColumn,s.endLineNumber,s.endColumn);let r=i.startLineNumber,o=i.startColumn;const a=[];for(let h=0,p=e.length;h0&&a.push(i.text),r=s.endLineNumber,o=s.endColumn}const l=a.join(""),[c,d,u]=(0,h.W)(l);return{sortIndex:0,identifier:e[0].identifier,range:n,rangeOffset:this.getOffsetAt(n.startLineNumber,n.startColumn),rangeLength:this.getValueLengthInRange(n,0),text:l,eolCount:c,firstLineLength:d,lastLineLength:u,forceMoveMarkers:t,isAutoWhitespaceEdit:!1}}_doApplyEdits(e){e.sort(Ge._sortOpsDescending);const t=[];for(let i=0;i0){const e=o.eolCount+1;c=1===e?new g.Q(a,l,a,l+o.firstLineLength):new g.Q(a,l,a+e-1,o.lastLineLength+1)}else c=new g.Q(a,l,a,l);i=c.endLineNumber,s=c.endColumn,t.push(c),n=o}return t}static _sortOpsAscending(e,t){const i=g.Q.compareRangesUsingEnds(e.range,t.range);return 0===i?e.sortIndex-t.sortIndex:i}static _sortOpsDescending(e,t){const i=g.Q.compareRangesUsingEnds(e.range,t.range);return 0===i?t.sortIndex-e.sortIndex:-i}}class je{constructor(e,t,i,s,n,r,o,a,l){this._chunks=e,this._bom=t,this._cr=i,this._lf=s,this._crlf=n,this._containsRTL=r,this._containsUnusualLineTerminators=o,this._isBasicASCII=a,this._normalizeEOL=l}_getEOL(e){const t=this._cr+this._lf+this._crlf,i=this._cr+this._crlf;return 0===t?1===e?"\n":"\r\n":i>t/2?"\r\n":"\n"}create(e){const t=this._getEOL(e),i=this._chunks;if(this._normalizeEOL&&("\r\n"===t&&(this._cr>0||this._lf>0)||"\n"===t&&(this._cr>0||this._crlf>0)))for(let n=0,r=i.length;n=55296&&t<=56319?(this._acceptChunk1(e.substr(0,e.length-1),!1),this._hasPreviousChar=!0,this._previousChar=t):(this._acceptChunk1(e,!1),this._hasPreviousChar=!1,this._previousChar=t)}_acceptChunk1(e,t){(t||0!==e.length)&&(this._hasPreviousChar?this._acceptChunk2(String.fromCharCode(this._previousChar)+e):this._acceptChunk2(e))}_acceptChunk2(e){const t=function(e,t){e.length=0,e[0]=0;let i=1,s=0,n=0,r=0,o=!0;for(let l=0,c=t.length;l126)&&(o=!1)}const a=new Pe(Me(e),s,n,r,o);return e.length=0,a}(this._tmpLineStarts,e);this.chunks.push(new He(e,t.lineStarts)),this.cr+=t.cr,this.lf+=t.lf,this.crlf+=t.crlf,t.isBasicASCII||(this.isBasicASCII=!1,this.containsRTL||(this.containsRTL=l.E_(e)),this.containsUnusualLineTerminators||(this.containsUnusualLineTerminators=l.$X(e)))}finish(e=!0){return this._finish(),new je(this.chunks,this.BOM,this.cr,this.lf,this.crlf,this.containsRTL,this.containsUnusualLineTerminators,this.isBasicASCII,e)}_finish(){if(0===this.chunks.length&&this._acceptChunk1("",!0),this._hasPreviousChar){this._hasPreviousChar=!1;const e=this.chunks[this.chunks.length-1];e.buffer+=String.fromCharCode(this._previousChar);const t=Fe(e.buffer);e.lineStarts=t,13===this._previousChar&&this.cr++}}}var Ye=i(86571),qe=i(26486),$e=i(62083),Qe=i(20761),Xe=i(90766),Ze=i(98067),Je=i(78381),et=i(74444),tt=i(20788);class it{constructor(e){this._default=e,this._store=[]}get(e){return e=this._store.length;)this._store[this._store.length]=this._default;this._store[e]=t}replace(e,t,i){if(e>=this._store.length)return;if(0===t)return void this.insert(e,i);if(0===i)return void this.delete(e,t);const s=this._store.slice(0,e),n=this._store.slice(e+t),r=function(e,t){const i=[];for(let s=0;s=this._store.length||this._store.splice(e,t)}insert(e,t){if(0===t||e>=this._store.length)return;const i=[];for(let s=0;s0){const i=this._tokens[this._tokens.length-1];if(i.endLineNumber+1===e)return void i.appendLineTokens(t)}this._tokens.push(new st(e,[t]))}finalize(){return this._tokens}}var rt=i(87469);class ot{constructor(e,t){this.tokenizationSupport=t,this.initialState=this.tokenizationSupport.getInitialState(),this.store=new lt(e)}getStartState(e){return this.store.getStartState(e,this.initialState)}getFirstInvalidLine(){return this.store.getFirstInvalidLine(this.initialState)}}class at extends ot{constructor(e,t,i,s){super(e,t),this._textModel=i,this._languageIdCodec=s}updateTokensUntilLine(e,t){const i=this._textModel.getLanguageId();for(;;){const s=this.getFirstInvalidLine();if(!s||s.lineNumber>t)break;const n=this._textModel.getLineContent(s.lineNumber),r=dt(this._languageIdCodec,i,this.tokenizationSupport,n,!0,s.startState);e.add(s.lineNumber,r.tokens),this.store.setEndState(s.lineNumber,r.endState)}}getTokenTypeIfInsertingCharacter(e,t){const i=this.getStartState(e.lineNumber);if(!i)return 0;const s=this._textModel.getLanguageId(),n=this._textModel.getLineContent(e.lineNumber),r=n.substring(0,e.column-1)+t+n.substring(e.column-1),o=dt(this._languageIdCodec,s,this.tokenizationSupport,r,!0,i),a=new rt.f(o.tokens,r,this._languageIdCodec);if(0===a.getCount())return 0;const l=a.findTokenIndexAtOffset(e.column-1);return a.getStandardTokenType(l)}tokenizeLineWithEdit(e,t,i){const s=e.lineNumber,n=e.column,r=this.getStartState(s);if(!r)return null;const o=this._textModel.getLineContent(s),a=o.substring(0,n-1)+i+o.substring(n-1+t),l=this._textModel.getLanguageIdAtPosition(s,0),c=dt(this._languageIdCodec,l,this.tokenizationSupport,a,!0,r);return new rt.f(c.tokens,a,this._languageIdCodec)}hasAccurateTokensForLine(e){return e1&&o>=1;o--){const e=this._textModel.getLineFirstNonWhitespaceColumn(o);if(0!==e&&(e0&&i>0&&(i--,t--),this._lineEndStates.replace(e.startLineNumber,i,t)}}class ht{constructor(){this._ranges=[]}get min(){return 0===this._ranges.length?null:this._ranges[0].start}delete(e){const t=this._ranges.findIndex((t=>t.contains(e)));if(-1!==t){const i=this._ranges[t];i.start===e?i.endExclusive===e+1?this._ranges.splice(t,1):this._ranges[t]=new et.L(e+1,i.endExclusive):i.endExclusive===e+1?this._ranges[t]=new et.L(i.start,e):this._ranges.splice(t,1,new et.L(i.start,e),new et.L(e+1,i.endExclusive))}}addRange(e){et.L.addRange(e,this._ranges)}addRangeAndResize(e,t){let i=0;for(;!(i>=this._ranges.length||e.start<=this._ranges[i].endExclusive);)i++;let s=i;for(;!(s>=this._ranges.length||e.endExclusivee.toString())).join(" + ")}}function dt(e,t,i,s,n,o){let a=null;if(i)try{a=i.tokenizeEncoded(s,n,o.clone())}catch(l){(0,r.dz)(l)}return a||(a=(0,tt.Lh)(e.encodeLanguageId(t),o)),rt.f.convertToEndOffset(a.tokens,s.length),a}class ut{constructor(e,t){this._tokenizerWithStateStore=e,this._backgroundTokenStore=t,this._isDisposed=!1,this._isScheduled=!1}dispose(){this._isDisposed=!0}handleChanges(){this._beginBackgroundTokenization()}_beginBackgroundTokenization(){!this._isScheduled&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._isScheduled=!0,(0,Xe.$6)((e=>{this._isScheduled=!1,this._backgroundTokenizeWithDeadline(e)})))}_backgroundTokenizeWithDeadline(e){const t=Date.now()+e.timeRemaining(),i=()=>{!this._isDisposed&&this._tokenizerWithStateStore._textModel.isAttachedToEditor()&&this._hasLinesToTokenize()&&(this._backgroundTokenizeForAtLeast1ms(),Date.now()1)break;if(this._tokenizeOneInvalidLine(t)>=e)break}while(this._hasLinesToTokenize());this._backgroundTokenStore.setTokens(t.finalize()),this.checkFinished()}_hasLinesToTokenize(){return!!this._tokenizerWithStateStore&&!this._tokenizerWithStateStore.store.allStatesValid()}_tokenizeOneInvalidLine(e){const t=this._tokenizerWithStateStore?.getFirstInvalidLine();return t?(this._tokenizerWithStateStore.updateTokensUntilLine(e,t.lineNumber),t.lineNumber):this._tokenizerWithStateStore._textModel.getLineCount()+1}checkFinished(){this._isDisposed||this._tokenizerWithStateStore.store.allStatesValid()&&this._backgroundTokenStore.backgroundTokenizationFinished()}requestTokens(e,t){this._tokenizerWithStateStore.store.invalidateEndStateRange(new Ye.M(e,t))}}class gt{constructor(){this._onDidChangeVisibleRanges=new o.vl,this.onDidChangeVisibleRanges=this._onDidChangeVisibleRanges.event,this._views=new Set}attachView(){const e=new pt((t=>{this._onDidChangeVisibleRanges.fire({view:e,state:t})}));return this._views.add(e),e}detachView(e){this._views.delete(e),this._onDidChangeVisibleRanges.fire({view:e,state:void 0})}}class pt{constructor(e){this.handleStateChange=e}setVisibleLines(e,t){const i=e.map((e=>new Ye.M(e.startLineNumber,e.endLineNumber+1)));this.handleStateChange({visibleLineRanges:i,stabilized:t})}}class mt extends a.jG{get lineRanges(){return this._lineRanges}constructor(e){super(),this._refreshTokens=e,this.runner=this._register(new Xe.uC((()=>this.update()),50)),this._computedLineRanges=[],this._lineRanges=[]}update(){(0,s.aI)(this._computedLineRanges,this._lineRanges,((e,t)=>e.equals(t)))||(this._computedLineRanges=this._lineRanges,this._refreshTokens())}handleStateChange(e){this._lineRanges=e.visibleLineRanges,e.stabilized?(this.runner.cancel(),this.update()):this.runner.schedule()}}class ft extends a.jG{get backgroundTokenizationState(){return this._backgroundTokenizationState}constructor(e,t,i){super(),this._languageIdCodec=e,this._textModel=t,this.getLanguageId=i,this._backgroundTokenizationState=1,this._onDidChangeBackgroundTokenizationState=this._register(new o.vl),this.onDidChangeBackgroundTokenizationState=this._onDidChangeBackgroundTokenizationState.event,this._onDidChangeTokens=this._register(new o.vl),this.onDidChangeTokens=this._onDidChangeTokens.event}tokenizeIfCheap(e){this.isCheapToTokenize(e)&&this.forceTokenization(e)}}class _t extends ft{constructor(e,t,i,s){super(t,i,s),this._treeSitterService=e,this._tokenizationSupport=null,this._initialize()}_initialize(){const e=this.getLanguageId();this._tokenizationSupport&&this._lastLanguageId===e||(this._lastLanguageId=e,this._tokenizationSupport=$e.OB.get(e))}getLineTokens(e){const t=this._textModel.getLineContent(e);if(this._tokenizationSupport){const i=this._tokenizationSupport.tokenizeEncoded(e,this._textModel);if(i)return new rt.f(i,t,this._languageIdCodec)}return rt.f.createEmpty(t,this._languageIdCodec)}resetTokenization(e=!0){e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]}),this._initialize()}handleDidChangeAttached(){}handleDidChangeContent(e){e.isFlush&&this.resetTokenization(!1)}forceTokenization(e){}hasAccurateTokensForLine(e){return!0}isCheapToTokenize(e){return!0}getTokenTypeIfInsertingCharacter(e,t,i){return 0}tokenizeLineWithEdit(e,t,i){return null}get hasTokens(){return void 0!==this._treeSitterService.getParseResult(this._textModel)}}var vt=i(44432);const Ct=new Uint32Array(0).buffer;class bt{static deleteBeginning(e,t){return null===e||e===Ct?e:bt.delete(e,0,t)}static deleteEnding(e,t){if(null===e||e===Ct)return e;const i=Et(e),s=i[i.length-2];return bt.delete(e,t,s)}static delete(e,t,i){if(null===e||e===Ct||t===i)return e;const s=Et(e),n=s.length>>>1;if(0===t&&s[s.length-2]===i)return Ct;const r=rt.f.findIndexInTokensArray(s,t),o=r>0?s[r-1<<1]:0;if(il&&(s[a++]=e,s[a++]=s[1+(d<<1)],l=e)}if(a===s.length)return e;const h=new Uint32Array(a);return h.set(s.subarray(0,a),0),h.buffer}static append(e,t){if(t===Ct)return e;if(e===Ct)return t;if(null===e)return e;if(null===t)return null;const i=Et(e),s=Et(t),n=s.length>>>1,r=new Uint32Array(i.length+s.length);r.set(i,0);let o=i.length;const a=i[i.length-2];for(let l=0;l>>1;let r=rt.f.findIndexInTokensArray(s,t);if(r>0){s[r-1<<1]===t&&r--}for(let o=r;o0}getTokens(e,t,i){let s=null;if(t1&&(t=St.x.getLanguageId(s[1])!==e),!t)return Ct}if(!s||0===s.length){const i=new Uint32Array(2);return i[0]=t,i[1]=wt(e),i.buffer}return s[s.length-2]=t,0===s.byteOffset&&s.byteLength===s.buffer.byteLength?s.buffer:s}_ensureLine(e){for(;e>=this._len;)this._lineTokens[this._len]=null,this._len++}_deleteLines(e,t){0!==t&&(e+t>this._len&&(t=this._len-e),this._lineTokens.splice(e,t),this._len-=t)}_insertLines(e,t){if(0===t)return;const i=[];for(let s=0;s=this._len)return;if(e.startLineNumber===e.endLineNumber){if(e.startColumn===e.endColumn)return;return void(this._lineTokens[t]=bt.delete(this._lineTokens[t],e.startColumn-1,e.endColumn-1))}this._lineTokens[t]=bt.deleteEnding(this._lineTokens[t],e.startColumn-1);const i=e.endLineNumber-1;let s=null;i=this._len||(0!==t?(this._lineTokens[s]=bt.deleteEnding(this._lineTokens[s],e.column-1),this._lineTokens[s]=bt.insert(this._lineTokens[s],e.column-1,i),this._insertLines(e.lineNumber,t)):this._lineTokens[s]=bt.insert(this._lineTokens[s],e.column-1,i))}setMultilineTokens(e,t){if(0===e.length)return{changes:[]};const i=[];for(let s=0,n=e.length;s>>0}class Lt{constructor(e){this._pieces=[],this._isComplete=!1,this._languageIdCodec=e}flush(){this._pieces=[],this._isComplete=!1}isEmpty(){return 0===this._pieces.length}set(e,t){this._pieces=e||[],this._isComplete=t}setPartial(e,t){let i=e;if(t.length>0){const s=t[0].getRange(),n=t[t.length-1].getRange();if(!s||!n)return e;i=e.plusRange(s).plusRange(n)}let n=null;for(let s=0,r=this._pieces.length;si.endLineNumber){n=n||{index:s};break}if(e.removeTokens(i),e.isEmpty()){this._pieces.splice(s,1),s--,r--;continue}if(e.endLineNumberi.endLineNumber){n=n||{index:s};continue}const[t,o]=e.split(i);t.isEmpty()?n=n||{index:s}:o.isEmpty()||(this._pieces.splice(s,1,t,o),s++,r++,n=n||{index:s})}return n=n||{index:this._pieces.length},t.length>0&&(this._pieces=s.nK(this._pieces,n.index,t)),i}isComplete(){return this._isComplete}addSparseTokens(e,t){if(0===t.getLineContent().length)return t;const i=this._pieces;if(0===i.length)return t;const s=i[Lt._findFirstPieceWithLine(i,e)].getLineTokens(e);if(!s)return t;const n=t.getCount(),r=s.getCount();let o=0;const a=[];let l=0,c=0;const h=(e,t)=>{e!==c&&(c=e,a[l++]=e,a[l++]=t)};for(let d=0;d>>0,l=~a>>>0;for(;ot)){for(;n>i&&e[n-1].startLineNumber<=t&&t<=e[n-1].endLineNumber;)n--;return n}s=n-1}}return i}acceptEdit(e,t,i,s,n){for(const r of this._pieces)r.acceptEdit(e,t,i,s,n)}}var Rt,Tt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},xt=function(e,t){return function(i,s){t(i,s,e)}};let kt=Rt=class extends Qe._{constructor(e,t,i,s,n,r,l){super(),this._textModel=e,this._bracketPairsTextModelPart=t,this._languageId=i,this._attachedViews=s,this._languageService=n,this._languageConfigurationService=r,this._treeSitterService=l,this._semanticTokens=new Lt(this._languageService.languageIdCodec),this._onDidChangeLanguage=this._register(new o.vl),this.onDidChangeLanguage=this._onDidChangeLanguage.event,this._onDidChangeLanguageConfiguration=this._register(new o.vl),this.onDidChangeLanguageConfiguration=this._onDidChangeLanguageConfiguration.event,this._onDidChangeTokens=this._register(new o.vl),this.onDidChangeTokens=this._onDidChangeTokens.event,this._tokensDisposables=this._register(new a.Cm),this._register(this._languageConfigurationService.onDidChange((e=>{e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}))),this._register(o.Jh.filter($e.OB.onDidChange,(e=>e.changedLanguages.includes(this._languageId)))((()=>{this.createPreferredTokenProvider()}))),this.createPreferredTokenProvider()}createGrammarTokens(){return this._register(new At(this._languageService.languageIdCodec,this._textModel,(()=>this._languageId),this._attachedViews))}createTreeSitterTokens(){return this._register(new _t(this._treeSitterService,this._languageService.languageIdCodec,this._textModel,(()=>this._languageId)))}createTokens(e){const t=void 0!==this._tokens;this._tokens?.dispose(),this._tokens=e?this.createTreeSitterTokens():this.createGrammarTokens(),this._tokensDisposables.clear(),this._tokensDisposables.add(this._tokens.onDidChangeTokens((e=>{this._emitModelTokensChangedEvent(e)}))),this._tokensDisposables.add(this._tokens.onDidChangeBackgroundTokenizationState((e=>{this._bracketPairsTextModelPart.handleDidChangeBackgroundTokenizationState()}))),t&&this._tokens.resetTokenization()}createPreferredTokenProvider(){$e.OB.get(this._languageId)?this._tokens instanceof _t||this.createTokens(!0):this._tokens instanceof At||this.createTokens(!1)}handleLanguageConfigurationServiceChange(e){e.affects(this._languageId)&&this._onDidChangeLanguageConfiguration.fire({})}handleDidChangeContent(e){if(e.isFlush)this._semanticTokens.flush();else if(!e.isEolChange)for(const t of e.changes){const[e,i,s]=(0,h.W)(t.text);this._semanticTokens.acceptEdit(t.range,e,i,s,t.text.length>0?t.text.charCodeAt(0):0)}this._tokens.handleDidChangeContent(e)}handleDidChangeAttached(){this._tokens.handleDidChangeAttached()}getLineTokens(e){this.validateLineNumber(e);const t=this._tokens.getLineTokens(e);return this._semanticTokens.addSparseTokens(e,t)}_emitModelTokensChangedEvent(e){this._textModel._isDisposing()||(this._bracketPairsTextModelPart.handleDidChangeTokens(e),this._onDidChangeTokens.fire(e))}validateLineNumber(e){if(e<1||e>this._textModel.getLineCount())throw new r.D7("Illegal value for lineNumber")}get hasTokens(){return this._tokens.hasTokens}resetTokenization(){this._tokens.resetTokenization()}get backgroundTokenizationState(){return this._tokens.backgroundTokenizationState}forceTokenization(e){this.validateLineNumber(e),this._tokens.forceTokenization(e)}hasAccurateTokensForLine(e){return this.validateLineNumber(e),this._tokens.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return this.validateLineNumber(e),this._tokens.isCheapToTokenize(e)}tokenizeIfCheap(e){this.validateLineNumber(e),this._tokens.tokenizeIfCheap(e)}getTokenTypeIfInsertingCharacter(e,t,i){return this._tokens.getTokenTypeIfInsertingCharacter(e,t,i)}tokenizeLineWithEdit(e,t,i){return this._tokens.tokenizeLineWithEdit(e,t,i)}setSemanticTokens(e,t){this._semanticTokens.set(e,t),this._emitModelTokensChangedEvent({semanticTokensApplied:null!==e,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]})}hasCompleteSemanticTokens(){return this._semanticTokens.isComplete()}hasSomeSemanticTokens(){return!this._semanticTokens.isEmpty()}setPartialSemanticTokens(e,t){if(this.hasCompleteSemanticTokens())return;const i=this._textModel.validateRange(this._semanticTokens.setPartial(e,t));this._emitModelTokensChangedEvent({semanticTokensApplied:!0,ranges:[{fromLineNumber:i.startLineNumber,toLineNumber:i.endLineNumber}]})}getWordAtPosition(e){this.assertNotDisposed();const t=this._textModel.validatePosition(e),i=this._textModel.getLineContent(t.lineNumber),s=this.getLineTokens(t.lineNumber),n=s.findTokenIndexAtOffset(t.column-1),[r,o]=Rt._findLanguageBoundaries(s,n),a=(0,qe.Th)(t.column,this.getLanguageConfiguration(s.getLanguageId(n)).getWordDefinition(),i.substring(r,o),r);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a;if(n>0&&r===t.column-1){const[r,o]=Rt._findLanguageBoundaries(s,n-1),a=(0,qe.Th)(t.column,this.getLanguageConfiguration(s.getLanguageId(n-1)).getWordDefinition(),i.substring(r,o),r);if(a&&a.startColumn<=e.column&&e.column<=a.endColumn)return a}return null}getLanguageConfiguration(e){return this._languageConfigurationService.getLanguageConfiguration(e)}static _findLanguageBoundaries(e,t){const i=e.getLanguageId(t);let s=0;for(let r=t;r>=0&&e.getLanguageId(r)===i;r--)s=e.getStartOffset(r);let n=e.getLineContent().length;for(let r=t,o=e.getCount();r{const t=this.getLanguageId();-1!==e.changedLanguages.indexOf(t)&&this.resetTokenization()}))),this.resetTokenization(),this._register(s.onDidChangeVisibleRanges((({view:e,state:t})=>{if(t){let i=this._attachedViewStates.get(e);i||(i=new mt((()=>this.refreshRanges(i.lineRanges))),this._attachedViewStates.set(e,i)),i.handleStateChange(t)}else this._attachedViewStates.deleteAndDispose(e)})))}resetTokenization(e=!0){this._tokens.flush(),this._debugBackgroundTokens?.flush(),this._debugBackgroundStates&&(this._debugBackgroundStates=new lt(this._textModel.getLineCount())),e&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:[{fromLineNumber:1,toLineNumber:this._textModel.getLineCount()}]});const[t,i]=(()=>{if(this._textModel.isTooLargeForTokenization())return[null,null];const e=$e.dG.get(this.getLanguageId());if(!e)return[null,null];let t;try{t=e.getInitialState()}catch(i){return(0,r.dz)(i),[null,null]}return[e,t]})();if(this._tokenizer=t&&i?new at(this._textModel.getLineCount(),t,this._textModel,this._languageIdCodec):null,this._backgroundTokenizer.clear(),this._defaultBackgroundTokenizer=null,this._tokenizer){const e={setTokens:e=>{this.setTokens(e)},backgroundTokenizationFinished:()=>{if(2===this._backgroundTokenizationState)return;this._backgroundTokenizationState=2,this._onDidChangeBackgroundTokenizationState.fire()},setEndState:(e,t)=>{if(!this._tokenizer)return;const i=this._tokenizer.store.getFirstInvalidEndStateLineNumber();null!==i&&e>=i&&this._tokenizer?.store.setEndState(e,t)}};t&&t.createBackgroundTokenizer&&!t.backgroundTokenizerShouldOnlyVerifyTokens&&(this._backgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,e)),this._backgroundTokenizer.value||this._textModel.isTooLargeForTokenization()||(this._backgroundTokenizer.value=this._defaultBackgroundTokenizer=new ut(this._tokenizer,e),this._defaultBackgroundTokenizer.handleChanges()),t?.backgroundTokenizerShouldOnlyVerifyTokens&&t.createBackgroundTokenizer?(this._debugBackgroundTokens=new yt(this._languageIdCodec),this._debugBackgroundStates=new lt(this._textModel.getLineCount()),this._debugBackgroundTokenizer.clear(),this._debugBackgroundTokenizer.value=t.createBackgroundTokenizer(this._textModel,{setTokens:e=>{this._debugBackgroundTokens?.setMultilineTokens(e,this._textModel)},backgroundTokenizationFinished(){},setEndState:(e,t)=>{this._debugBackgroundStates?.setEndState(e,t)}})):(this._debugBackgroundTokens=void 0,this._debugBackgroundStates=void 0,this._debugBackgroundTokenizer.value=void 0)}this.refreshAllVisibleLineTokens()}handleDidChangeAttached(){this._defaultBackgroundTokenizer?.handleChanges()}handleDidChangeContent(e){if(e.isFlush)this.resetTokenization(!1);else if(!e.isEolChange){for(const t of e.changes){const[e,i]=(0,h.W)(t.text);this._tokens.acceptEdit(t.range,e,i),this._debugBackgroundTokens?.acceptEdit(t.range,e,i)}this._debugBackgroundStates?.acceptChanges(e.changes),this._tokenizer&&this._tokenizer.store.acceptChanges(e.changes),this._defaultBackgroundTokenizer?.handleChanges()}}setTokens(e){const{changes:t}=this._tokens.setMultilineTokens(e,this._textModel);return t.length>0&&this._onDidChangeTokens.fire({semanticTokensApplied:!1,ranges:t}),{changes:t}}refreshAllVisibleLineTokens(){const e=Ye.M.joinMany([...this._attachedViewStates].map((([e,t])=>t.lineRanges)));this.refreshRanges(e)}refreshRanges(e){for(const t of e)this.refreshRange(t.startLineNumber,t.endLineNumberExclusive-1)}refreshRange(e,t){if(!this._tokenizer)return;e=Math.max(1,Math.min(this._textModel.getLineCount(),e)),t=Math.min(this._textModel.getLineCount(),t);const i=new nt,{heuristicTokens:s}=this._tokenizer.tokenizeHeuristically(i,e,t),n=this.setTokens(i.finalize());if(s)for(const r of n.changes)this._backgroundTokenizer.value?.requestTokens(r.fromLineNumber,r.toLineNumber+1);this._defaultBackgroundTokenizer?.checkFinished()}forceTokenization(e){const t=new nt;this._tokenizer?.updateTokensUntilLine(t,e),this.setTokens(t.finalize()),this._defaultBackgroundTokenizer?.checkFinished()}hasAccurateTokensForLine(e){return!this._tokenizer||this._tokenizer.hasAccurateTokensForLine(e)}isCheapToTokenize(e){return!this._tokenizer||this._tokenizer.isCheapToTokenize(e)}getLineTokens(e){const t=this._textModel.getLineContent(e),i=this._tokens.getTokens(this._textModel.getLanguageId(),e-1,t);if(this._debugBackgroundTokens&&this._debugBackgroundStates&&this._tokenizer&&this._debugBackgroundStates.getFirstInvalidEndStateLineNumberOrMax()>e&&this._tokenizer.store.getFirstInvalidEndStateLineNumberOrMax()>e){const s=this._debugBackgroundTokens.getTokens(this._textModel.getLanguageId(),e-1,t);!i.equals(s)&&this._debugBackgroundTokenizer.value?.reportMismatchingTokens&&this._debugBackgroundTokenizer.value.reportMismatchingTokens(e)}return i}getTokenTypeIfInsertingCharacter(e,t,i){if(!this._tokenizer)return 0;const s=this._textModel.validatePosition(new u.y(e,t));return this.forceTokenization(s.lineNumber),this._tokenizer.getTokenTypeIfInsertingCharacter(s,i)}tokenizeLineWithEdit(e,t,i){if(!this._tokenizer)return null;const s=this._textModel.validatePosition(e);return this.forceTokenization(s.lineNumber),this._tokenizer.tokenizeLineWithEdit(s,t,i)}get hasTokens(){return this._tokens.hasTokens}}var Nt,It=i(64727),Ot=i(63591),Dt=i(47579),Mt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Pt=function(e,t){return function(i,s){t(i,s,e)}};function Ft(e,t){let i;return i="string"===typeof e?function(e){const t=new Ke;return t.acceptChunk(e),t.finish()}(e):v.nk(e)?function(e){const t=new Ke;let i;for(;"string"===typeof(i=e.read());)t.acceptChunk(i);return t.finish()}(e):e,i.create(t)}let Ut=0;class Ht{constructor(e){this._source=e,this._eos=!1}read(){if(this._eos)return null;const e=[];let t=0,i=0;for(;;){const s=this._source.read();if(null===s)return this._eos=!0,0===t?null:e.join("");if(s.length>0&&(e[t++]=s,i+=s.length),i>=65536)return e.join("")}}}const Bt=()=>{throw new Error("Invalid change accessor")};let Wt=class extends a.jG{static{Nt=this}static{this._MODEL_SYNC_LIMIT=52428800}static{this.LARGE_FILE_SIZE_THRESHOLD=20971520}static{this.LARGE_FILE_LINE_COUNT_THRESHOLD=3e5}static{this.LARGE_FILE_HEAP_OPERATION_THRESHOLD=268435456}static{this.DEFAULT_CREATION_OPTIONS={isForSimpleWidget:!1,tabSize:m.R.tabSize,indentSize:m.R.indentSize,insertSpaces:m.R.insertSpaces,detectIndentation:!1,defaultEOL:1,trimAutoWhitespace:m.R.trimAutoWhitespace,largeFileOptimizations:m.R.largeFileOptimizations,bracketPairColorizationOptions:m.R.bracketPairColorizationOptions}}static resolveOptions(e,t){if(t.detectIndentation){const i=$(e,t.tabSize,t.insertSpaces);return new v.X2({tabSize:i.tabSize,indentSize:"tabSize",insertSpaces:i.insertSpaces,trimAutoWhitespace:t.trimAutoWhitespace,defaultEOL:t.defaultEOL,bracketPairColorizationOptions:t.bracketPairColorizationOptions})}return new v.X2(t)}get onDidChangeLanguage(){return this._tokenizationTextModelPart.onDidChangeLanguage}get onDidChangeLanguageConfiguration(){return this._tokenizationTextModelPart.onDidChangeLanguageConfiguration}get onDidChangeTokens(){return this._tokenizationTextModelPart.onDidChangeTokens}onDidChangeContent(e){return this._eventEmitter.slowEvent((t=>e(t.contentChangedEvent)))}onDidChangeContentOrInjectedText(e){return(0,a.qE)(this._eventEmitter.fastEvent((t=>e(t))),this._onDidChangeInjectedText.event((t=>e(t))))}_isDisposing(){return this.__isDisposing}get tokenization(){return this._tokenizationTextModelPart}get bracketPairs(){return this._bracketPairs}get guides(){return this._guidesTextModelPart}constructor(e,t,i,s=null,n,r,h,d){super(),this._undoRedoService=n,this._languageService=r,this._languageConfigurationService=h,this.instantiationService=d,this._onWillDispose=this._register(new o.vl),this.onWillDispose=this._onWillDispose.event,this._onDidChangeDecorations=this._register(new ei((e=>this.handleBeforeFireDecorationsChangedEvent(e)))),this.onDidChangeDecorations=this._onDidChangeDecorations.event,this._onDidChangeOptions=this._register(new o.vl),this.onDidChangeOptions=this._onDidChangeOptions.event,this._onDidChangeAttached=this._register(new o.vl),this.onDidChangeAttached=this._onDidChangeAttached.event,this._onDidChangeInjectedText=this._register(new o.vl),this._eventEmitter=this._register(new ti),this._languageSelectionListener=this._register(new a.HE),this._deltaDecorationCallCnt=0,this._attachedViews=new gt,Ut++,this.id="$model"+Ut,this.isForSimpleWidget=i.isForSimpleWidget,this._associatedResource="undefined"===typeof s||null===s?c.r.parse("inmemory://model/"+Ut):s,this._attachedEditorCount=0;const{textBuffer:u,disposable:p}=Ft(e,i.defaultEOL);this._buffer=u,this._bufferDisposable=p,this._options=Nt.resolveOptions(this._buffer,i);const m="string"===typeof t?t:t.languageId;"string"!==typeof t&&(this._languageSelectionListener.value=t.onDidChange((()=>this._setLanguage(t.languageId)))),this._bracketPairs=this._register(new F(this,this._languageConfigurationService)),this._guidesTextModelPart=this._register(new K.P(this,this._languageConfigurationService)),this._decorationProvider=this._register(new z(this)),this._tokenizationTextModelPart=this.instantiationService.createInstance(kt,this,this._bracketPairs,m,this._attachedViews);const f=this._buffer.getLineCount(),_=this._buffer.getValueLengthInRange(new g.Q(1,1,f,this._buffer.getLineLength(f)+1),0);i.largeFileOptimizations?(this._isTooLargeForTokenization=_>Nt.LARGE_FILE_SIZE_THRESHOLD||f>Nt.LARGE_FILE_LINE_COUNT_THRESHOLD,this._isTooLargeForHeapOperation=_>Nt.LARGE_FILE_HEAP_OPERATION_THRESHOLD):(this._isTooLargeForTokenization=!1,this._isTooLargeForHeapOperation=!1),this._isTooLargeForSyncing=_>Nt._MODEL_SYNC_LIMIT,this._versionId=1,this._alternativeVersionId=1,this._initialUndoRedoSnapshot=null,this._isDisposed=!1,this.__isDisposing=!1,this._instanceId=l.tk(Ut),this._lastDecorationId=0,this._decorations=Object.create(null),this._decorationsTree=new Gt,this._commandManager=new j.z8(this,this._undoRedoService),this._isUndoing=!1,this._isRedoing=!1,this._trimAutoWhitespaceLines=null,this._register(this._decorationProvider.onDidChange((()=>{this._onDidChangeDecorations.beginDeferredEmit(),this._onDidChangeDecorations.fire(),this._onDidChangeDecorations.endDeferredEmit()}))),this._languageService.requestRichLanguageFeatures(m),this._register(this._languageConfigurationService.onDidChange((e=>{this._bracketPairs.handleLanguageConfigurationServiceChange(e),this._tokenizationTextModelPart.handleLanguageConfigurationServiceChange(e)})))}dispose(){this.__isDisposing=!0,this._onWillDispose.fire(),this._tokenizationTextModelPart.dispose(),this._isDisposed=!0,super.dispose(),this._bufferDisposable.dispose(),this.__isDisposing=!1;const e=new Ge([],"","\n",!1,!1,!0,!0);e.dispose(),this._buffer=e,this._bufferDisposable=a.jG.None}_assertNotDisposed(){if(this._isDisposed)throw new r.D7("Model is disposed!")}_emitContentChangedEvent(e,t){this.__isDisposing||(this._tokenizationTextModelPart.handleDidChangeContent(t),this._bracketPairs.handleDidChangeContent(t),this._eventEmitter.fire(new It.Ic(e,t)))}setValue(e){if(this._assertNotDisposed(),null===e||void 0===e)throw(0,r.Qg)();const{textBuffer:t,disposable:i}=Ft(e,this._options.defaultEOL);this._setValueFromTextBuffer(t,i)}_createContentChanged2(e,t,i,s,n,r,o,a){return{changes:[{range:e,rangeOffset:t,rangeLength:i,text:s}],eol:this._buffer.getEOL(),isEolChange:a,versionId:this.getVersionId(),isUndoing:n,isRedoing:r,isFlush:o}}_setValueFromTextBuffer(e,t){this._assertNotDisposed();const i=this.getFullModelRange(),s=this.getValueLengthInRange(i),n=this.getLineCount(),r=this.getLineMaxColumn(n);this._buffer=e,this._bufferDisposable.dispose(),this._bufferDisposable=t,this._increaseVersionId(),this._decorations=Object.create(null),this._decorationsTree=new Gt,this._commandManager.clear(),this._trimAutoWhitespaceLines=null,this._emitContentChangedEvent(new It.HP([new It.Wn],this._versionId,!1,!1),this._createContentChanged2(new g.Q(1,1,n,r),0,s,this.getValue(),!1,!1,!0,!1))}setEOL(e){this._assertNotDisposed();const t=1===e?"\r\n":"\n";if(this._buffer.getEOL()===t)return;const i=this.getFullModelRange(),s=this.getValueLengthInRange(i),n=this.getLineCount(),r=this.getLineMaxColumn(n);this._onBeforeEOLChange(),this._buffer.setEOL(t),this._increaseVersionId(),this._onAfterEOLChange(),this._emitContentChangedEvent(new It.HP([new It.mS],this._versionId,!1,!1),this._createContentChanged2(new g.Q(1,1,n,r),0,s,this.getValue(),!1,!1,!1,!0))}_onBeforeEOLChange(){this._decorationsTree.ensureAllNodesHaveRanges(this)}_onAfterEOLChange(){const e=this.getVersionId(),t=this._decorationsTree.collectNodesPostOrder();for(let i=0,s=t.length;i0}getAttachedEditorCount(){return this._attachedEditorCount}isTooLargeForSyncing(){return this._isTooLargeForSyncing}isTooLargeForTokenization(){return this._isTooLargeForTokenization}isTooLargeForHeapOperation(){return this._isTooLargeForHeapOperation}isDisposed(){return this._isDisposed}isDominatedByLongLines(){if(this._assertNotDisposed(),this.isTooLargeForTokenization())return!1;let e=0,t=0;const i=this._buffer.getLineCount();for(let s=1;s<=i;s++){const i=this._buffer.getLineLength(s);i>=1e4?t+=i:e+=i}return t>e}get uri(){return this._associatedResource}getOptions(){return this._assertNotDisposed(),this._options}getFormattingOptions(){return{tabSize:this._options.indentSize,insertSpaces:this._options.insertSpaces}}updateOptions(e){this._assertNotDisposed();const t="undefined"!==typeof e.tabSize?e.tabSize:this._options.tabSize,i="undefined"!==typeof e.indentSize?e.indentSize:this._options.originalIndentSize,s="undefined"!==typeof e.insertSpaces?e.insertSpaces:this._options.insertSpaces,n="undefined"!==typeof e.trimAutoWhitespace?e.trimAutoWhitespace:this._options.trimAutoWhitespace,r="undefined"!==typeof e.bracketColorizationOptions?e.bracketColorizationOptions:this._options.bracketPairColorizationOptions,o=new v.X2({tabSize:t,indentSize:i,insertSpaces:s,defaultEOL:this._options.defaultEOL,trimAutoWhitespace:n,bracketPairColorizationOptions:r});if(this._options.equals(o))return;const a=this._options.createChangeEvent(o);this._options=o,this._bracketPairs.handleDidChangeOptions(a),this._decorationProvider.handleDidChangeOptions(a),this._onDidChangeOptions.fire(a)}detectIndentation(e,t){this._assertNotDisposed();const i=$(this._buffer,t,e);this.updateOptions({insertSpaces:i.insertSpaces,tabSize:i.tabSize,indentSize:i.tabSize})}normalizeIndentation(e){return this._assertNotDisposed(),(0,d.P)(e,this._options.indentSize,this._options.insertSpaces)}getVersionId(){return this._assertNotDisposed(),this._versionId}mightContainRTL(){return this._buffer.mightContainRTL()}mightContainUnusualLineTerminators(){return this._buffer.mightContainUnusualLineTerminators()}removeUnusualLineTerminators(e=null){const t=this.findMatches(l._J.source,!1,!0,!1,null,!1,1073741824);this._buffer.resetMightContainUnusualLineTerminators(),this.pushEditOperations(e,t.map((e=>({range:e.range,text:null}))),(()=>null))}mightContainNonBasicASCII(){return this._buffer.mightContainNonBasicASCII()}getAlternativeVersionId(){return this._assertNotDisposed(),this._alternativeVersionId}getInitialUndoRedoSnapshot(){return this._assertNotDisposed(),this._initialUndoRedoSnapshot}getOffsetAt(e){this._assertNotDisposed();const t=this._validatePosition(e.lineNumber,e.column,0);return this._buffer.getOffsetAt(t.lineNumber,t.column)}getPositionAt(e){this._assertNotDisposed();const t=Math.min(this._buffer.getLength(),Math.max(0,e));return this._buffer.getPositionAt(t)}_increaseVersionId(){this._versionId=this._versionId+1,this._alternativeVersionId=this._versionId}_overwriteVersionId(e){this._versionId=e}_overwriteAlternativeVersionId(e){this._alternativeVersionId=e}_overwriteInitialUndoRedoSnapshot(e){this._initialUndoRedoSnapshot=e}getValue(e,t=!1){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new r.D7("Operation would exceed heap memory limits");const i=this.getFullModelRange(),s=this.getValueInRange(i,e);return t?this._buffer.getBOM()+s:s}createSnapshot(e=!1){return new Ht(this._buffer.createSnapshot(e))}getValueLength(e,t=!1){this._assertNotDisposed();const i=this.getFullModelRange(),s=this.getValueLengthInRange(i,e);return t?this._buffer.getBOM().length+s:s}getValueInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueInRange(this.validateRange(e),t)}getValueLengthInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getValueLengthInRange(this.validateRange(e),t)}getCharacterCountInRange(e,t=0){return this._assertNotDisposed(),this._buffer.getCharacterCountInRange(this.validateRange(e),t)}getLineCount(){return this._assertNotDisposed(),this._buffer.getLineCount()}getLineContent(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineContent(e)}getLineLength(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)}getLinesContent(){if(this._assertNotDisposed(),this.isTooLargeForHeapOperation())throw new r.D7("Operation would exceed heap memory limits");return this._buffer.getLinesContent()}getEOL(){return this._assertNotDisposed(),this._buffer.getEOL()}getEndOfLineSequence(){return this._assertNotDisposed(),"\n"===this._buffer.getEOL()?0:1}getLineMinColumn(e){return this._assertNotDisposed(),1}getLineMaxColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineLength(e)+1}getLineFirstNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineFirstNonWhitespaceColumn(e)}getLineLastNonWhitespaceColumn(e){if(this._assertNotDisposed(),e<1||e>this.getLineCount())throw new r.D7("Illegal value for lineNumber");return this._buffer.getLineLastNonWhitespaceColumn(e)}_validateRangeRelaxedNoAllocations(e){const t=this._buffer.getLineCount(),i=e.startLineNumber,s=e.startColumn;let n=Math.floor("number"!==typeof i||isNaN(i)?1:i),r=Math.floor("number"!==typeof s||isNaN(s)?1:s);if(n<1)n=1,r=1;else if(n>t)n=t,r=this.getLineMaxColumn(n);else if(r<=1)r=1;else{const e=this.getLineMaxColumn(n);r>=e&&(r=e)}const o=e.endLineNumber,a=e.endColumn;let l=Math.floor("number"!==typeof o||isNaN(o)?1:o),c=Math.floor("number"!==typeof a||isNaN(a)?1:a);if(l<1)l=1,c=1;else if(l>t)l=t,c=this.getLineMaxColumn(l);else if(c<=1)c=1;else{const e=this.getLineMaxColumn(l);c>=e&&(c=e)}return i===n&&s===r&&o===l&&a===c&&e instanceof g.Q&&!(e instanceof p.L)?e:new g.Q(n,r,l,c)}_isValidPosition(e,t,i){if("number"!==typeof e||"number"!==typeof t)return!1;if(isNaN(e)||isNaN(t))return!1;if(e<1||t<1)return!1;if((0|e)!==e||(0|t)!==t)return!1;if(e>this._buffer.getLineCount())return!1;if(1===t)return!0;if(t>this.getLineMaxColumn(e))return!1;if(1===i){const i=this._buffer.getLineCharCode(e,t-2);if(l.pc(i))return!1}return!0}_validatePosition(e,t,i){const s=Math.floor("number"!==typeof e||isNaN(e)?1:e),n=Math.floor("number"!==typeof t||isNaN(t)?1:t),r=this._buffer.getLineCount();if(s<1)return new u.y(1,1);if(s>r)return new u.y(r,this.getLineMaxColumn(r));if(n<=1)return new u.y(s,1);const o=this.getLineMaxColumn(s);if(n>=o)return new u.y(s,o);if(1===i){const e=this._buffer.getLineCharCode(s,n-2);if(l.pc(e))return new u.y(s,n-1)}return new u.y(s,n)}validatePosition(e){return this._assertNotDisposed(),e instanceof u.y&&this._isValidPosition(e.lineNumber,e.column,1)?e:this._validatePosition(e.lineNumber,e.column,1)}_isValidRange(e,t){const i=e.startLineNumber,s=e.startColumn,n=e.endLineNumber,r=e.endColumn;if(!this._isValidPosition(i,s,0))return!1;if(!this._isValidPosition(n,r,0))return!1;if(1===t){const e=s>1?this._buffer.getLineCharCode(i,s-2):0,t=r>1&&r<=this._buffer.getLineLength(n)?this._buffer.getLineCharCode(n,r-2):0,o=l.pc(e),a=l.pc(t);return!o&&!a}return!0}validateRange(e){if(this._assertNotDisposed(),e instanceof g.Q&&!(e instanceof p.L)&&this._isValidRange(e,1))return e;const t=this._validatePosition(e.startLineNumber,e.startColumn,0),i=this._validatePosition(e.endLineNumber,e.endColumn,0),s=t.lineNumber,n=t.column,r=i.lineNumber,o=i.column;{const e=n>1?this._buffer.getLineCharCode(s,n-2):0,t=o>1&&o<=this._buffer.getLineLength(r)?this._buffer.getLineCharCode(r,o-2):0,i=l.pc(e),a=l.pc(t);return i||a?s===r&&n===o?new g.Q(s,n-1,r,o-1):i&&a?new g.Q(s,n-1,r,o+1):i?new g.Q(s,n-1,r,o):new g.Q(s,n,r,o+1):new g.Q(s,n,r,o)}}modifyPosition(e,t){this._assertNotDisposed();const i=this.getOffsetAt(e)+t;return this.getPositionAt(Math.min(this._buffer.getLength(),Math.max(0,i)))}getFullModelRange(){this._assertNotDisposed();const e=this.getLineCount();return new g.Q(1,1,e,this.getLineMaxColumn(e))}findMatchesLineByLine(e,t,i,s){return this._buffer.findMatchesLineByLine(e,t,i,s)}findMatches(e,t,i,s,n,r,o=999){this._assertNotDisposed();let a=null;null!==t&&(Array.isArray(t)||(t=[t]),t.every((e=>g.Q.isIRange(e)))&&(a=t.map((e=>this.validateRange(e))))),null===a&&(a=[this.getFullModelRange()]),a=a.sort(((e,t)=>e.startLineNumber-t.startLineNumber||e.startColumn-t.startColumn));const l=[];let c;if(l.push(a.reduce(((e,t)=>g.Q.areIntersecting(e,t)?e.plusRange(t):(l.push(e),t)))),!i&&e.indexOf("\n")<0){const t=new Oe.lt(e,i,s,n).parseSearchRequest();if(!t)return[];c=e=>this.findMatchesLineByLine(e,t,r,o)}else c=t=>Oe.hB.findMatches(this,new Oe.lt(e,i,s,n),t,r,o);return l.map(c).reduce(((e,t)=>e.concat(t)),[])}findNextMatch(e,t,i,s,n,r){this._assertNotDisposed();const o=this.validatePosition(t);if(!i&&e.indexOf("\n")<0){const t=new Oe.lt(e,i,s,n).parseSearchRequest();if(!t)return null;const a=this.getLineCount();let l=new g.Q(o.lineNumber,o.column,a,this.getLineMaxColumn(a)),c=this.findMatchesLineByLine(l,t,r,1);return Oe.hB.findNextMatch(this,new Oe.lt(e,i,s,n),o,r),c.length>0?c[0]:(l=new g.Q(1,1,o.lineNumber,this.getLineMaxColumn(o.lineNumber)),c=this.findMatchesLineByLine(l,t,r,1),c.length>0?c[0]:null)}return Oe.hB.findNextMatch(this,new Oe.lt(e,i,s,n),o,r)}findPreviousMatch(e,t,i,s,n,r){this._assertNotDisposed();const o=this.validatePosition(t);return Oe.hB.findPreviousMatch(this,new Oe.lt(e,i,s,n),o,r)}pushStackElement(){this._commandManager.pushStackElement()}popStackElement(){this._commandManager.popStackElement()}pushEOL(e){if(("\n"===this.getEOL()?0:1)!==e)try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEOL(e)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_validateEditOperation(e){return e instanceof v.Wo?e:new v.Wo(e.identifier||null,this.validateRange(e.range),e.text,e.forceMoveMarkers||!1,e.isAutoWhitespaceEdit||!1,e._isTracked||!1)}_validateEditOperations(e){const t=[];for(let i=0,s=e.length;i({range:this.validateRange(e.range),text:e.text})));let s=!0;if(e)for(let t=0,n=e.length;tn.endLineNumber,o=n.startLineNumber>t.endLineNumber;if(!s&&!o){r=!0;break}}if(!r){s=!1;break}}if(s)for(let e=0,n=this._trimAutoWhitespaceLines.length;et.endLineNumber)&&(!(s===t.startLineNumber&&t.startColumn===n&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(0))&&!(s===t.startLineNumber&&1===t.startColumn&&t.isEmpty()&&o&&o.length>0&&"\n"===o.charAt(o.length-1)))){r=!1;break}}if(r){const e=new g.Q(s,1,s,n);t.push(new v.Wo(null,e,null,!1,!1,!1))}}this._trimAutoWhitespaceLines=null}return null===this._initialUndoRedoSnapshot&&(this._initialUndoRedoSnapshot=this._undoRedoService.createSnapshot(this.uri)),this._commandManager.pushEditOperation(e,t,i,s)}_applyUndo(e,t,i,s){const n=e.map((e=>{const t=this.getPositionAt(e.newPosition),i=this.getPositionAt(e.newEnd);return{range:new g.Q(t.lineNumber,t.column,i.lineNumber,i.column),text:e.oldText}}));this._applyUndoRedoEdits(n,t,!0,!1,i,s)}_applyRedo(e,t,i,s){const n=e.map((e=>{const t=this.getPositionAt(e.oldPosition),i=this.getPositionAt(e.oldEnd);return{range:new g.Q(t.lineNumber,t.column,i.lineNumber,i.column),text:e.newText}}));this._applyUndoRedoEdits(n,t,!1,!0,i,s)}_applyUndoRedoEdits(e,t,i,s,n,r){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit(),this._isUndoing=i,this._isRedoing=s,this.applyEdits(e,!1),this.setEOL(t),this._overwriteAlternativeVersionId(n)}finally{this._isUndoing=!1,this._isRedoing=!1,this._eventEmitter.endDeferredEmit(r),this._onDidChangeDecorations.endDeferredEmit()}}applyEdits(e,t=!1){try{this._onDidChangeDecorations.beginDeferredEmit(),this._eventEmitter.beginDeferredEmit();const i=this._validateEditOperations(e);return this._doApplyEdits(i,t)}finally{this._eventEmitter.endDeferredEmit(),this._onDidChangeDecorations.endDeferredEmit()}}_doApplyEdits(e,t){const i=this._buffer.getLineCount(),n=this._buffer.applyEdits(e,this._options.trimAutoWhitespace,t),r=this._buffer.getLineCount(),o=n.changes;if(this._trimAutoWhitespaceLines=n.trimAutoWhitespaceLineNumbers,0!==o.length){for(let i=0,s=o.length;i=0;t--){const i=l+t,s=f+t;E.takeFromEndWhile((e=>e.lineNumber>s));const n=E.takeFromEndWhile((e=>e.lineNumber===s));e.push(new It.U0(i,this.getLineContent(s),n))}if(pe.lineNumbere.lineNumber===t))}e.push(new It.bg(n+1,l+g,h,c))}t+=m}this._emitContentChangedEvent(new It.HP(e,this.getVersionId(),this._isUndoing,this._isRedoing),{changes:o,eol:this._buffer.getEOL(),isEolChange:!1,versionId:this.getVersionId(),isUndoing:this._isUndoing,isRedoing:this._isRedoing,isFlush:!1})}return null===n.reverseEdits?void 0:n.reverseEdits}undo(){return this._undoRedoService.undo(this.uri)}canUndo(){return this._undoRedoService.canUndo(this.uri)}redo(){return this._undoRedoService.redo(this.uri)}canRedo(){return this._undoRedoService.canRedo(this.uri)}handleBeforeFireDecorationsChangedEvent(e){if(null===e||0===e.size)return;const t=Array.from(e).map((e=>new It.U0(e,this.getLineContent(e),this._getInjectedTextInLine(e))));this._onDidChangeInjectedText.fire(new It.vn(t))}changeDecorations(e,t=0){this._assertNotDisposed();try{return this._onDidChangeDecorations.beginDeferredEmit(),this._changeDecorations(t,e)}finally{this._onDidChangeDecorations.endDeferredEmit()}}_changeDecorations(e,t){const i={addDecoration:(t,i)=>this._deltaDecorationsImpl(e,[],[{range:t,options:i}])[0],changeDecoration:(e,t)=>{this._changeDecorationImpl(e,t)},changeDecorationOptions:(e,t)=>{this._changeDecorationOptionsImpl(e,Jt(t))},removeDecoration:t=>{this._deltaDecorationsImpl(e,[t],[])},deltaDecorations:(t,i)=>0===t.length&&0===i.length?[]:this._deltaDecorationsImpl(e,t,i)};let s=null;try{s=t(i)}catch(n){(0,r.dz)(n)}return i.addDecoration=Bt,i.changeDecoration=Bt,i.changeDecorationOptions=Bt,i.removeDecoration=Bt,i.deltaDecorations=Bt,s}deltaDecorations(e,t,i=0){if(this._assertNotDisposed(),e||(e=[]),0===e.length&&0===t.length)return[];try{return this._deltaDecorationCallCnt++,this._deltaDecorationCallCnt>1&&(console.warn("Invoking deltaDecorations recursively could lead to leaking decorations."),(0,r.dz)(new Error("Invoking deltaDecorations recursively could lead to leaking decorations."))),this._onDidChangeDecorations.beginDeferredEmit(),this._deltaDecorationsImpl(i,e,t)}finally{this._onDidChangeDecorations.endDeferredEmit(),this._deltaDecorationCallCnt--}}_getTrackedRange(e){return this.getDecorationRange(e)}_setTrackedRange(e,t,i){const s=e?this._decorations[e]:null;if(!s)return t?this._deltaDecorationsImpl(0,[],[{range:t,options:Zt[i]}],!0)[0]:null;if(!t)return this._decorationsTree.delete(s),delete this._decorations[s.id],null;const n=this._validateRangeRelaxedNoAllocations(t),r=this._buffer.getOffsetAt(n.startLineNumber,n.startColumn),o=this._buffer.getOffsetAt(n.endLineNumber,n.endColumn);return this._decorationsTree.delete(s),s.reset(this.getVersionId(),r,o,n),s.setOptions(Zt[i]),this._decorationsTree.insert(s),s.id}removeAllDecorationsWithOwnerId(e){if(this._isDisposed)return;const t=this._decorationsTree.collectNodesFromOwner(e);for(let i=0,s=t.length;ithis.getLineCount()?[]:this.getLinesDecorations(e,e,t,i)}getLinesDecorations(e,t,i=0,n=!1,r=!1){const o=this.getLineCount(),a=Math.min(o,Math.max(1,e)),l=Math.min(o,Math.max(1,t)),c=this.getLineMaxColumn(l),h=new g.Q(a,1,l,c),d=this._getDecorationsInRange(h,i,n,r);return(0,s.E4)(d,this._decorationProvider.getDecorationsInRange(h,i,n)),d}getDecorationsInRange(e,t=0,i=!1,n=!1,r=!1){const o=this.validateRange(e),a=this._getDecorationsInRange(o,t,i,r);return(0,s.E4)(a,this._decorationProvider.getDecorationsInRange(o,t,i,n)),a}getOverviewRulerDecorations(e=0,t=!1){return this._decorationsTree.getAll(this,e,t,!0,!1)}getInjectedTextDecorations(e=0){return this._decorationsTree.getAllInjectedText(this,e)}_getInjectedTextInLine(e){const t=this._buffer.getOffsetAt(e,1),i=t+this._buffer.getLineLength(e),s=this._decorationsTree.getInjectedTextInInterval(this,t,i,0);return It.uK.fromDecorations(s).filter((t=>t.lineNumber===e))}getAllDecorations(e=0,t=!1){let i=this._decorationsTree.getAll(this,e,t,!1,!1);return i=i.concat(this._decorationProvider.getAllDecorations(e,t)),i}getAllMarginDecorations(e=0){return this._decorationsTree.getAll(this,e,!1,!1,!0)}_getDecorationsInRange(e,t,i,s){const n=this._buffer.getOffsetAt(e.startLineNumber,e.startColumn),r=this._buffer.getOffsetAt(e.endLineNumber,e.endColumn);return this._decorationsTree.getAllInInterval(this,n,r,t,i,s)}getRangeAt(e,t){return this._buffer.getRangeAt(e,t-e)}_changeDecorationImpl(e,t){const i=this._decorations[e];if(!i)return;if(i.options.after){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.endLineNumber)}if(i.options.before){const t=this.getDecorationRange(e);this._onDidChangeDecorations.recordLineAffectedByInjectedText(t.startLineNumber)}const s=this._validateRangeRelaxedNoAllocations(t),n=this._buffer.getOffsetAt(s.startLineNumber,s.startColumn),r=this._buffer.getOffsetAt(s.endLineNumber,s.endColumn);this._decorationsTree.delete(i),i.reset(this.getVersionId(),n,r,s),this._decorationsTree.insert(i),this._onDidChangeDecorations.checkAffectedAndFire(i.options),i.options.after&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(s.endLineNumber),i.options.before&&this._onDidChangeDecorations.recordLineAffectedByInjectedText(s.startLineNumber)}_changeDecorationOptionsImpl(e,t){const i=this._decorations[e];if(!i)return;const s=!(!i.options.overviewRuler||!i.options.overviewRuler.color),n=!(!t.overviewRuler||!t.overviewRuler.color);if(this._onDidChangeDecorations.checkAffectedAndFire(i.options),this._onDidChangeDecorations.checkAffectedAndFire(t),i.options.after||t.after){const e=this._decorationsTree.getNodeRange(this,i);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.endLineNumber)}if(i.options.before||t.before){const e=this._decorationsTree.getNodeRange(this,i);this._onDidChangeDecorations.recordLineAffectedByInjectedText(e.startLineNumber)}const r=s!==n,o=function(e){return!!e.after||!!e.before}(t)!==zt(i);r||o?(this._decorationsTree.delete(i),i.setOptions(t),this._decorationsTree.insert(i)):i.setOptions(t)}_deltaDecorationsImpl(e,t,i,s=!1){const n=this.getVersionId(),r=t.length;let o=0;const a=i.length;let l=0;this._onDidChangeDecorations.beginDeferredEmit();try{const c=new Array(a);for(;othis._setLanguage(e.languageId,t))),this._setLanguage(e.languageId,t))}_setLanguage(e,t){this.tokenization.setLanguageId(e,t),this._languageService.requestRichLanguageFeatures(e)}getLanguageIdAtPosition(e,t){return this.tokenization.getLanguageIdAtPosition(e,t)}getWordAtPosition(e){return this._tokenizationTextModelPart.getWordAtPosition(e)}getWordUntilPosition(e){return this._tokenizationTextModelPart.getWordUntilPosition(e)}normalizePosition(e,t){return e}getLineIndentColumn(e){return function(e){let t=0;for(const i of e){if(" "!==i&&"\t"!==i)break;t++}return t}(this.getLineContent(e))+1}};function Vt(e){return!(!e.options.overviewRuler||!e.options.overviewRuler.color)}function zt(e){return!!e.options.after||!!e.options.before}Wt=Nt=Mt([Pt(4,Dt.$D),Pt(5,f.L),Pt(6,_.JZ),Pt(7,Ot._Y)],Wt);class Gt{constructor(){this._decorationsTree0=new le,this._decorationsTree1=new le,this._injectedTextDecorationsTree=new le}ensureAllNodesHaveRanges(e){this.getAll(e,0,!1,!1,!1)}_ensureNodesHaveRanges(e,t){for(const i of t)null===i.range&&(i.range=e.getRangeAt(i.cachedAbsoluteStart,i.cachedAbsoluteEnd));return t}getAllInInterval(e,t,i,s,n,r){const o=e.getVersionId(),a=this._intervalSearch(t,i,s,n,o,r);return this._ensureNodesHaveRanges(e,a)}_intervalSearch(e,t,i,s,n,r){const o=this._decorationsTree0.intervalSearch(e,t,i,s,n,r),a=this._decorationsTree1.intervalSearch(e,t,i,s,n,r),l=this._injectedTextDecorationsTree.intervalSearch(e,t,i,s,n,r);return o.concat(a).concat(l)}getInjectedTextInInterval(e,t,i,s){const n=e.getVersionId(),r=this._injectedTextDecorationsTree.intervalSearch(t,i,s,!1,n,!1);return this._ensureNodesHaveRanges(e,r).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAllInjectedText(e,t){const i=e.getVersionId(),s=this._injectedTextDecorationsTree.search(t,!1,i,!1);return this._ensureNodesHaveRanges(e,s).filter((e=>e.options.showIfCollapsed||!e.range.isEmpty()))}getAll(e,t,i,s,n){const r=e.getVersionId(),o=this._search(t,i,s,r,n);return this._ensureNodesHaveRanges(e,o)}_search(e,t,i,s,n){if(i)return this._decorationsTree1.search(e,t,s,n);{const i=this._decorationsTree0.search(e,t,s,n),r=this._decorationsTree1.search(e,t,s,n),o=this._injectedTextDecorationsTree.search(e,t,s,n);return i.concat(r).concat(o)}}collectNodesFromOwner(e){const t=this._decorationsTree0.collectNodesFromOwner(e),i=this._decorationsTree1.collectNodesFromOwner(e),s=this._injectedTextDecorationsTree.collectNodesFromOwner(e);return t.concat(i).concat(s)}collectNodesPostOrder(){const e=this._decorationsTree0.collectNodesPostOrder(),t=this._decorationsTree1.collectNodesPostOrder(),i=this._injectedTextDecorationsTree.collectNodesPostOrder();return e.concat(t).concat(i)}insert(e){zt(e)?this._injectedTextDecorationsTree.insert(e):Vt(e)?this._decorationsTree1.insert(e):this._decorationsTree0.insert(e)}delete(e){zt(e)?this._injectedTextDecorationsTree.delete(e):Vt(e)?this._decorationsTree1.delete(e):this._decorationsTree0.delete(e)}getNodeRange(e,t){const i=e.getVersionId();return t.cachedVersionId!==i&&this._resolveNode(t,i),null===t.range&&(t.range=e.getRangeAt(t.cachedAbsoluteStart,t.cachedAbsoluteEnd)),t.range}_resolveNode(e,t){zt(e)?this._injectedTextDecorationsTree.resolveNode(e,t):Vt(e)?this._decorationsTree1.resolveNode(e,t):this._decorationsTree0.resolveNode(e,t)}acceptReplace(e,t,i,s){this._decorationsTree0.acceptReplace(e,t,i,s),this._decorationsTree1.acceptReplace(e,t,i,s),this._injectedTextDecorationsTree.acceptReplace(e,t,i,s)}}function jt(e){return e.replace(/[^a-z0-9\-_]/gi," ")}class Kt{constructor(e){this.color=e.color||"",this.darkColor=e.darkColor||""}}class Yt extends Kt{constructor(e){super(e),this._resolvedColor=null,this.position="number"===typeof e.position?e.position:v.A5.Center}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=null}_resolveColor(e,t){if("string"===typeof e)return e;const i=e?t.getColor(e.id):null;return i?i.toString():""}}class qt{constructor(e){this.position=e?.position??v.ZS.Center,this.persistLane=e?.persistLane}}class $t extends Kt{constructor(e){super(e),this.position=e.position,this.sectionHeaderStyle=e.sectionHeaderStyle??null,this.sectionHeaderText=e.sectionHeaderText??null}getColor(e){return this._resolvedColor||("light"!==e.type&&this.darkColor?this._resolvedColor=this._resolveColor(this.darkColor,e):this._resolvedColor=this._resolveColor(this.color,e)),this._resolvedColor}invalidateCachedColor(){this._resolvedColor=void 0}_resolveColor(e,t){return"string"===typeof e?n.Q1.fromHex(e):t.getColor(e.id)}}class Qt{static from(e){return e instanceof Qt?e:new Qt(e)}constructor(e){this.content=e.content||"",this.inlineClassName=e.inlineClassName||null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.attachedData=e.attachedData||null,this.cursorStops=e.cursorStops||null}}class Xt{static register(e){return new Xt(e)}static createDynamic(e){return new Xt(e)}constructor(e){this.description=e.description,this.blockClassName=e.blockClassName?jt(e.blockClassName):null,this.blockDoesNotCollapse=e.blockDoesNotCollapse??null,this.blockIsAfterEnd=e.blockIsAfterEnd??null,this.blockPadding=e.blockPadding??null,this.stickiness=e.stickiness||0,this.zIndex=e.zIndex||0,this.className=e.className?jt(e.className):null,this.shouldFillLineOnLineBreak=e.shouldFillLineOnLineBreak??null,this.hoverMessage=e.hoverMessage||null,this.glyphMarginHoverMessage=e.glyphMarginHoverMessage||null,this.lineNumberHoverMessage=e.lineNumberHoverMessage||null,this.isWholeLine=e.isWholeLine||!1,this.showIfCollapsed=e.showIfCollapsed||!1,this.collapseOnReplaceEdit=e.collapseOnReplaceEdit||!1,this.overviewRuler=e.overviewRuler?new Yt(e.overviewRuler):null,this.minimap=e.minimap?new $t(e.minimap):null,this.glyphMargin=e.glyphMarginClassName?new qt(e.glyphMargin):null,this.glyphMarginClassName=e.glyphMarginClassName?jt(e.glyphMarginClassName):null,this.linesDecorationsClassName=e.linesDecorationsClassName?jt(e.linesDecorationsClassName):null,this.lineNumberClassName=e.lineNumberClassName?jt(e.lineNumberClassName):null,this.linesDecorationsTooltip=e.linesDecorationsTooltip?l.jy(e.linesDecorationsTooltip):null,this.firstLineDecorationClassName=e.firstLineDecorationClassName?jt(e.firstLineDecorationClassName):null,this.marginClassName=e.marginClassName?jt(e.marginClassName):null,this.inlineClassName=e.inlineClassName?jt(e.inlineClassName):null,this.inlineClassNameAffectsLetterSpacing=e.inlineClassNameAffectsLetterSpacing||!1,this.beforeContentClassName=e.beforeContentClassName?jt(e.beforeContentClassName):null,this.afterContentClassName=e.afterContentClassName?jt(e.afterContentClassName):null,this.after=e.after?Qt.from(e.after):null,this.before=e.before?Qt.from(e.before):null,this.hideInCommentTokens=e.hideInCommentTokens??!1,this.hideInStringTokens=e.hideInStringTokens??!1}}Xt.EMPTY=Xt.register({description:"empty"});const Zt=[Xt.register({description:"tracked-range-always-grows-when-typing-at-edges",stickiness:0}),Xt.register({description:"tracked-range-never-grows-when-typing-at-edges",stickiness:1}),Xt.register({description:"tracked-range-grows-only-when-typing-before",stickiness:2}),Xt.register({description:"tracked-range-grows-only-when-typing-after",stickiness:3})];function Jt(e){return e instanceof Xt?e:Xt.createDynamic(e)}class ei extends a.jG{constructor(e){super(),this.handleBeforeFire=e,this._actual=this._register(new o.vl),this.event=this._actual.event,this._affectedInjectedTextLines=null,this._deferredCnt=0,this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._affectsLineNumber=!1}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(){this._deferredCnt--,0===this._deferredCnt&&(this._shouldFireDeferred&&this.doFire(),this._affectedInjectedTextLines?.clear(),this._affectedInjectedTextLines=null)}recordLineAffectedByInjectedText(e){this._affectedInjectedTextLines||(this._affectedInjectedTextLines=new Set),this._affectedInjectedTextLines.add(e)}checkAffectedAndFire(e){this._affectsMinimap||=!!e.minimap?.position,this._affectsOverviewRuler||=!!e.overviewRuler?.color,this._affectsGlyphMargin||=!!e.glyphMarginClassName,this._affectsLineNumber||=!!e.lineNumberClassName,this.tryFire()}fire(){this._affectsMinimap=!0,this._affectsOverviewRuler=!0,this._affectsGlyphMargin=!0,this.tryFire()}tryFire(){0===this._deferredCnt?this.doFire():this._shouldFireDeferred=!0}doFire(){this.handleBeforeFire(this._affectedInjectedTextLines);const e={affectsMinimap:this._affectsMinimap,affectsOverviewRuler:this._affectsOverviewRuler,affectsGlyphMargin:this._affectsGlyphMargin,affectsLineNumber:this._affectsLineNumber};this._shouldFireDeferred=!1,this._affectsMinimap=!1,this._affectsOverviewRuler=!1,this._affectsGlyphMargin=!1,this._actual.fire(e)}}class ti extends a.jG{constructor(){super(),this._fastEmitter=this._register(new o.vl),this.fastEvent=this._fastEmitter.event,this._slowEmitter=this._register(new o.vl),this.slowEvent=this._slowEmitter.event,this._deferredCnt=0,this._deferredEvent=null}beginDeferredEmit(){this._deferredCnt++}endDeferredEmit(e=null){if(this._deferredCnt--,0===this._deferredCnt&&null!==this._deferredEvent){this._deferredEvent.rawContentChangedEvent.resultingSelection=e;const t=this._deferredEvent;this._deferredEvent=null,this._fastEmitter.fire(t),this._slowEmitter.fire(t)}}fire(e){this._deferredCnt>0?this._deferredEvent?this._deferredEvent=this._deferredEvent.merge(e):this._deferredEvent=e:(this._fastEmitter.fire(e),this._slowEmitter.fire(e))}}},20761:(e,t,i)=>{"use strict";i.d(t,{_:()=>n});var s=i(5662);class n extends s.jG{constructor(){super(...arguments),this._isDisposed=!1}dispose(){super.dispose(),this._isDisposed=!0}assertNotDisposed(){if(this._isDisposed)throw new Error("TextModelPart is disposed!")}}},43264:(e,t,i)=>{"use strict";i.d(t,{W5:()=>g,dr:()=>c,hB:()=>d,lt:()=>l,wC:()=>u});var s=i(91508),n=i(81782),r=i(83069),o=i(36677),a=i(16223);class l{constructor(e,t,i,s){this.searchString=e,this.isRegex=t,this.matchCase=i,this.wordSeparators=s}parseSearchRequest(){if(""===this.searchString)return null;let e;e=this.isRegex?function(e){if(!e||0===e.length)return!1;for(let t=0,i=e.length;t=i)break;const s=e.charCodeAt(t);if(110===s||114===s||87===s)return!0}}return!1}(this.searchString):this.searchString.indexOf("\n")>=0;let t=null;try{t=s.OS(this.searchString,this.isRegex,{matchCase:this.matchCase,wholeWord:!1,multiline:e,global:!0,unicode:!0})}catch(r){return null}if(!t)return null;let i=!this.isRegex&&!e;return i&&this.searchString.toLowerCase()!==this.searchString.toUpperCase()&&(i=this.matchCase),new a.L5(t,this.wordSeparators?(0,n.i)(this.wordSeparators,[]):null,i?this.searchString:null)}}function c(e,t,i){if(!i)return new a.Dg(e,null);const s=[];for(let n=0,r=t.length;n=e?s=n-1:t[n+1]>=e?(i=n,s=n):i=n+1}return i+1}}class d{static findMatches(e,t,i,s,n){const r=t.parseSearchRequest();return r?r.regex.multiline?this._doFindMatchesMultiline(e,i,new g(r.wordSeparators,r.regex),s,n):this._doFindMatchesLineByLine(e,i,r,s,n):[]}static _getMultilineMatchRange(e,t,i,s,n,r){let a,l,c=0;if(s?(c=s.findLineFeedCountBeforeOffset(n),a=t+n+c):a=t+n,s){const e=s.findLineFeedCountBeforeOffset(n+r.length)-c;l=a+r.length+e}else l=a+r.length;const h=e.getPositionAt(a),d=e.getPositionAt(l);return new o.Q(h.lineNumber,h.column,d.lineNumber,d.column)}static _doFindMatchesMultiline(e,t,i,s,n){const r=e.getOffsetAt(t.getStartPosition()),o=e.getValueInRange(t,1),a="\r\n"===e.getEOL()?new h(o):null,l=[];let d,u=0;for(i.reset(0);d=i.next(o);)if(l[u++]=c(this._getMultilineMatchRange(e,r,o,a,d.index,d[0]),d,s),u>=n)return l;return l}static _doFindMatchesLineByLine(e,t,i,s,n){const r=[];let o=0;if(t.startLineNumber===t.endLineNumber){const a=e.getLineContent(t.startLineNumber).substring(t.startColumn-1,t.endColumn-1);return o=this._findMatchesInLine(i,a,t.startLineNumber,t.startColumn-1,o,r,s,n),r}const a=e.getLineContent(t.startLineNumber).substring(t.startColumn-1);o=this._findMatchesInLine(i,a,t.startLineNumber,t.startColumn-1,o,r,s,n);for(let l=t.startLineNumber+1;l=h))return n;return n}const p=new g(e.wordSeparators,e.regex);let m;p.reset(0);do{if(m=p.next(t),m&&(r[n++]=c(new o.Q(i,m.index+1+s,i,m.index+1+m[0].length+s),m,l),n>=h))return n}while(m);return n}static findNextMatch(e,t,i,s){const n=t.parseSearchRequest();if(!n)return null;const r=new g(n.wordSeparators,n.regex);return n.regex.multiline?this._doFindNextMatchMultiline(e,i,r,s):this._doFindNextMatchLineByLine(e,i,r,s)}static _doFindNextMatchMultiline(e,t,i,s){const n=new r.y(t.lineNumber,1),a=e.getOffsetAt(n),l=e.getLineCount(),d=e.getValueInRange(new o.Q(n.lineNumber,n.column,l,e.getLineMaxColumn(l)),1),u="\r\n"===e.getEOL()?new h(d):null;i.reset(t.column-1);const g=i.next(d);return g?c(this._getMultilineMatchRange(e,a,d,u,g.index,g[0]),g,s):1!==t.lineNumber||1!==t.column?this._doFindNextMatchMultiline(e,new r.y(1,1),i,s):null}static _doFindNextMatchLineByLine(e,t,i,s){const n=e.getLineCount(),r=t.lineNumber,o=e.getLineContent(r),a=this._findFirstMatchInLine(i,o,r,t.column,s);if(a)return a;for(let l=1;l<=n;l++){const t=(r+l-1)%n,o=e.getLineContent(t+1),a=this._findFirstMatchInLine(i,o,t+1,1,s);if(a)return a}return null}static _findFirstMatchInLine(e,t,i,s,n){e.reset(s-1);const r=e.next(t);return r?c(new o.Q(i,r.index+1,i,r.index+1+r[0].length),r,n):null}static findPreviousMatch(e,t,i,s){const n=t.parseSearchRequest();if(!n)return null;const r=new g(n.wordSeparators,n.regex);return n.regex.multiline?this._doFindPreviousMatchMultiline(e,i,r,s):this._doFindPreviousMatchLineByLine(e,i,r,s)}static _doFindPreviousMatchMultiline(e,t,i,s){const n=this._doFindMatchesMultiline(e,new o.Q(1,1,t.lineNumber,t.column),i,s,9990);if(n.length>0)return n[n.length-1];const a=e.getLineCount();return t.lineNumber!==a||t.column!==e.getLineMaxColumn(a)?this._doFindPreviousMatchMultiline(e,new r.y(a,e.getLineMaxColumn(a)),i,s):null}static _doFindPreviousMatchLineByLine(e,t,i,s){const n=e.getLineCount(),r=t.lineNumber,o=e.getLineContent(r).substring(0,t.column-1),a=this._findLastMatchInLine(i,o,r,s);if(a)return a;for(let l=1;l<=n;l++){const t=(n+r-l-1)%n,o=e.getLineContent(t+1),a=this._findLastMatchInLine(i,o,t+1,s);if(a)return a}return null}static _findLastMatchInLine(e,t,i,s){let n,r=null;for(e.reset(0);n=e.next(t);)r=c(new o.Q(i,n.index+1,i,n.index+1+n[0].length),n,s);return r}}function u(e,t,i,s,n){return function(e,t,i,s,n){if(0===s)return!0;const r=t.charCodeAt(s-1);if(0!==e.get(r))return!0;if(13===r||10===r)return!0;if(n>0){const i=t.charCodeAt(s);if(0!==e.get(i))return!0}return!1}(e,t,0,s,n)&&function(e,t,i,s,n){if(s+n===i)return!0;const r=t.charCodeAt(s+n);if(0!==e.get(r))return!0;if(13===r||10===r)return!0;if(n>0){const i=t.charCodeAt(s+n-1);if(0!==e.get(i))return!0}return!1}(e,t,i,s,n)}class g{constructor(e,t){this._wordSeparators=e,this._searchRegex=t,this._prevMatchStartIndex=-1,this._prevMatchLength=0}reset(e){this._searchRegex.lastIndex=e,this._prevMatchStartIndex=-1,this._prevMatchLength=0}next(e){const t=e.length;let i;do{if(this._prevMatchStartIndex+this._prevMatchLength===t)return null;if(i=this._searchRegex.exec(e),!i)return null;const n=i.index,r=i[0].length;if(n===this._prevMatchStartIndex&&r===this._prevMatchLength){if(0===r){s.Z5(e,t,this._searchRegex.lastIndex)>65535?this._searchRegex.lastIndex+=2:this._searchRegex.lastIndex+=1;continue}return null}if(this._prevMatchStartIndex=n,this._prevMatchLength=r,!this._wordSeparators||u(this._wordSeparators,e,t,n,r))return i}while(i);return null}}},78049:(e,t,i)=>{"use strict";function s(e,t){let i=0,s=0;const n=e.length;for(;ss})},73848:(e,t,i)=>{"use strict";i.r(t),i.d(t,{KeyMod:()=>u,createMonacoBaseAPI:()=>g});var s=i(18447),n=i(41234),r=i(24939),o=i(79400),a=i(83069),l=i(36677),c=i(75326),h=i(62083),d=i(35015);class u{static{this.CtrlCmd=2048}static{this.Shift=1024}static{this.Alt=512}static{this.WinCtrl=256}static chord(e,t){return(0,r.m5)(e,t)}}function g(){return{editor:void 0,languages:void 0,CancellationTokenSource:s.Qi,Emitter:n.vl,KeyCode:d.DD,KeyMod:u,Position:a.y,Range:l.Q,Selection:c.L,SelectionDirection:d.SB,MarkerSeverity:d.cj,MarkerTag:d.d_,Uri:o.r,Token:h.ou}}},16545:(e,t,i)=>{"use strict";i.r(t),i.d(t,{BaseEditorSimpleWorker:()=>Y,EditorSimpleWorker:()=>q,create:()=>$});var s=i(83993),n=i(36677),r=i(60534);class o{constructor(e,t,i){const s=new Uint8Array(e*t);for(let n=0,r=e*t;nt&&(t=r),s>i&&(i=s),o>i&&(i=o)}t++,i++;const s=new o(i,t,0);for(let n=0,r=e.length;n=this._maxCharCode?0:this._states.get(e,t)}}let l=null;let c=null;class h{static _createLink(e,t,i,s,n){let r=n-1;do{const i=t.charCodeAt(r);if(2!==e.get(i))break;r--}while(r>s);if(s>0){const e=t.charCodeAt(s-1),i=t.charCodeAt(r);(40===e&&41===i||91===e&&93===i||123===e&&125===i)&&r--}return{range:{startLineNumber:i,startColumn:s+1,endLineNumber:i,endColumn:r+2},url:t.substring(s,r+1)}}static computeLinks(e,t=function(){return null===l&&(l=new a([[1,104,2],[1,72,2],[1,102,6],[1,70,6],[2,116,3],[2,84,3],[3,116,4],[3,84,4],[4,112,5],[4,80,5],[5,115,9],[5,83,9],[5,58,10],[6,105,7],[6,73,7],[7,108,8],[7,76,8],[8,101,9],[8,69,9],[9,58,10],[10,47,11],[11,47,12]])),l}()){const i=function(){if(null===c){c=new r.V(0);const e=" \t<>'\"\u3001\u3002\uff61\uff64\uff0c\uff0e\uff1a\uff1b\u2018\u3008\u300c\u300e\u3014\uff08\uff3b\uff5b\uff62\uff63\uff5d\uff3d\uff09\u3015\u300f\u300d\u3009\u2019\uff40\uff5e\u2026";for(let i=0;i=0?(s+=i?1:-1,s<0?s=e.length-1:s%=e.length,e[s]):null}}var u=i(73848),g=i(80718),p=i(78381),m=i(74855),f=i(41845),_=i(87723),v=i(91508),C=i(66782),b=i(86571);class E{computeDiff(e,t,i){const s=new T(e,t,{maxComputationTime:i.maxComputationTimeMs,shouldIgnoreTrimWhitespace:i.ignoreTrimWhitespace,shouldComputeCharChanges:!0,shouldMakePrettyDiff:!0,shouldPostProcessCharChanges:!0}).computeDiff(),r=[];let o=null;for(const a of s.changes){let e,t;e=0===a.originalEndLineNumber?new b.M(a.originalStartLineNumber+1,a.originalStartLineNumber+1):new b.M(a.originalStartLineNumber,a.originalEndLineNumber+1),t=0===a.modifiedEndLineNumber?new b.M(a.modifiedStartLineNumber+1,a.modifiedStartLineNumber+1):new b.M(a.modifiedStartLineNumber,a.modifiedEndLineNumber+1);let i=new _.wm(e,t,a.charChanges?.map((e=>new _.q6(new n.Q(e.originalStartLineNumber,e.originalStartColumn,e.originalEndLineNumber,e.originalEndColumn),new n.Q(e.modifiedStartLineNumber,e.modifiedStartColumn,e.modifiedEndLineNumber,e.modifiedEndColumn)))));o&&(o.modified.endLineNumberExclusive!==i.modified.startLineNumber&&o.original.endLineNumberExclusive!==i.original.startLineNumber||(i=new _.wm(o.original.join(i.original),o.modified.join(i.modified),o.innerChanges&&i.innerChanges?o.innerChanges.concat(i.innerChanges):void 0),r.pop())),r.push(i),o=i}return(0,C.Ft)((()=>(0,C.Xo)(r,((e,t)=>t.original.startLineNumber-e.original.endLineNumberExclusive===t.modified.startLineNumber-e.modified.endLineNumberExclusive&&e.original.endLineNumberExclusive(10===e?"\\n":String.fromCharCode(e))+`-(${this._lineNumbers[t]},${this._columns[t]})`)).join(", ")+"]"}_assertIndex(e,t){if(e<0||e>=t.length)throw new Error("Illegal index")}getElements(){return this._charCodes}getStartLineNumber(e){return e>0&&e===this._lineNumbers.length?this.getEndLineNumber(e-1):(this._assertIndex(e,this._lineNumbers),this._lineNumbers[e])}getEndLineNumber(e){return-1===e?this.getStartLineNumber(e+1):(this._assertIndex(e,this._lineNumbers),10===this._charCodes[e]?this._lineNumbers[e]+1:this._lineNumbers[e])}getStartColumn(e){return e>0&&e===this._columns.length?this.getEndColumn(e-1):(this._assertIndex(e,this._columns),this._columns[e])}getEndColumn(e){return-1===e?this.getStartColumn(e+1):(this._assertIndex(e,this._columns),10===this._charCodes[e]?1:this._columns[e]+1)}}class L{constructor(e,t,i,s,n,r,o,a){this.originalStartLineNumber=e,this.originalStartColumn=t,this.originalEndLineNumber=i,this.originalEndColumn=s,this.modifiedStartLineNumber=n,this.modifiedStartColumn=r,this.modifiedEndLineNumber=o,this.modifiedEndColumn=a}static createFromDiffChange(e,t,i){const s=t.getStartLineNumber(e.originalStart),n=t.getStartColumn(e.originalStart),r=t.getEndLineNumber(e.originalStart+e.originalLength-1),o=t.getEndColumn(e.originalStart+e.originalLength-1),a=i.getStartLineNumber(e.modifiedStart),l=i.getStartColumn(e.modifiedStart),c=i.getEndLineNumber(e.modifiedStart+e.modifiedLength-1),h=i.getEndColumn(e.modifiedStart+e.modifiedLength-1);return new L(s,n,r,o,a,l,c,h)}}class R{constructor(e,t,i,s,n){this.originalStartLineNumber=e,this.originalEndLineNumber=t,this.modifiedStartLineNumber=i,this.modifiedEndLineNumber=s,this.charChanges=n}static createFromDiffResult(e,t,i,s,n,r,o){let a,l,c,h,d;if(0===t.originalLength?(a=i.getStartLineNumber(t.originalStart)-1,l=0):(a=i.getStartLineNumber(t.originalStart),l=i.getEndLineNumber(t.originalStart+t.originalLength-1)),0===t.modifiedLength?(c=s.getStartLineNumber(t.modifiedStart)-1,h=0):(c=s.getStartLineNumber(t.modifiedStart),h=s.getEndLineNumber(t.modifiedStart+t.modifiedLength-1)),r&&t.originalLength>0&&t.originalLength<20&&t.modifiedLength>0&&t.modifiedLength<20&&n()){const r=i.createCharSequence(e,t.originalStart,t.originalStart+t.originalLength-1),a=s.createCharSequence(e,t.modifiedStart,t.modifiedStart+t.modifiedLength-1);if(r.getElements().length>0&&a.getElements().length>0){let e=S(r,a,n,!0).changes;o&&(e=function(e){if(e.length<=1)return e;const t=[e[0]];let i=t[0];for(let s=1,n=e.length;s1&&o>1;){if(e.charCodeAt(i-2)!==t.charCodeAt(o-2))break;i--,o--}(i>1||o>1)&&this._pushTrimWhitespaceCharChange(s,n+1,1,i,r+1,1,o)}{let i=k(e,1),o=k(t,1);const a=e.length+1,l=t.length+1;for(;i!0;const t=Date.now();return()=>Date.now()-tnew E,O=()=>new N.D8;var D=i(10146),M=i(36456),P=i(47661);function F(e){const t=[];for(const i of e){const e=Number(i);(e||0===e&&""!==i.replace(/\s/g,""))&&t.push(e)}return t}function U(e,t,i,s){return{red:e/255,blue:i/255,green:t/255,alpha:s}}function H(e,t){const i=t.index,s=t[0].length;if(!i)return;const n=e.positionAt(i);return{startLineNumber:n.lineNumber,startColumn:n.column,endLineNumber:n.lineNumber,endColumn:n.column+s}}function B(e,t){if(!e)return;const i=P.Q1.Format.CSS.parseHex(t);return i?{range:e,color:U(i.rgba.r,i.rgba.g,i.rgba.b,i.rgba.a)}:void 0}function W(e,t,i){if(!e||1!==t.length)return;const s=F(t[0].values());return{range:e,color:U(s[0],s[1],s[2],i?s[3]:1)}}function V(e,t,i){if(!e||1!==t.length)return;const s=F(t[0].values()),n=new P.Q1(new P.hB(s[0],s[1]/100,s[2]/100,i?s[3]:1));return{range:e,color:U(n.rgba.r,n.rgba.g,n.rgba.b,n.rgba.a)}}function z(e,t){return"string"===typeof e?[...e.matchAll(t)]:e.findMatches(t)}function G(e){return e&&"function"===typeof e.getValue&&"function"===typeof e.positionAt?function(e){const t=[],i=z(e,/\b(rgb|rgba|hsl|hsla)(\([0-9\s,.\%]*\))|(#)([A-Fa-f0-9]{3})\b|(#)([A-Fa-f0-9]{4})\b|(#)([A-Fa-f0-9]{6})\b|(#)([A-Fa-f0-9]{8})\b/gm);if(i.length>0)for(const s of i){const i=s.filter((e=>void 0!==e)),n=i[1],r=i[2];if(!r)continue;let o;if("rgb"===n){const t=/^\(\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*\)$/gm;o=W(H(e,s),z(r,t),!1)}else if("rgba"===n){const t=/^\(\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(25[0-5]|2[0-4][0-9]|1[0-9]{2}|[1-9][0-9]|[0-9])\s*,\s*(0[.][0-9]+|[.][0-9]+|[01][.]|[01])\s*\)$/gm;o=W(H(e,s),z(r,t),!0)}else if("hsl"===n){const t=/^\(\s*(36[0]|3[0-5][0-9]|[12][0-9][0-9]|[1-9]?[0-9])\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*\)$/gm;o=V(H(e,s),z(r,t),!1)}else if("hsla"===n){const t=/^\(\s*(36[0]|3[0-5][0-9]|[12][0-9][0-9]|[1-9]?[0-9])\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(100|\d{1,2}[.]\d*|\d{1,2})%\s*,\s*(0[.][0-9]+|[.][0-9]+|[01][.]|[01])\s*\)$/gm;o=V(H(e,s),z(r,t),!0)}else"#"===n&&(o=B(H(e,s),n+r));o&&t.push(o)}return t}(e):[]}var j=i(56691),K=i(47443);class Y{constructor(){this._workerTextModelSyncServer=new K.WorkerTextModelSyncServer}dispose(){}_getModel(e){return this._workerTextModelSyncServer.getModel(e)}_getModels(){return this._workerTextModelSyncServer.getModels()}$acceptNewModel(e){this._workerTextModelSyncServer.$acceptNewModel(e)}$acceptModelChanged(e,t){this._workerTextModelSyncServer.$acceptModelChanged(e,t)}$acceptRemovedModel(e){this._workerTextModelSyncServer.$acceptRemovedModel(e)}async $computeUnicodeHighlights(e,t,i){const s=this._getModel(e);return s?m.UnicodeTextModelHighlighter.computeUnicodeHighlights(s,t,i):{ranges:[],hasMore:!1,ambiguousCharacterCount:0,invisibleCharacterCount:0,nonBasicAsciiCharacterCount:0}}async $findSectionHeaders(e,t){const i=this._getModel(e);return i?(0,j.findSectionHeaders)(i,t):[]}async $computeDiff(e,t,i,s){const n=this._getModel(e),r=this._getModel(t);if(!n||!r)return null;return q.computeDiff(n,r,i,s)}static computeDiff(e,t,i,s){const n="advanced"===s?O():I(),r=e.getLinesContent(),o=t.getLinesContent(),a=n.computeDiff(r,o,i);function l(e){return e.map((e=>[e.original.startLineNumber,e.original.endLineNumberExclusive,e.modified.startLineNumber,e.modified.endLineNumberExclusive,e.innerChanges?.map((e=>[e.originalRange.startLineNumber,e.originalRange.startColumn,e.originalRange.endLineNumber,e.originalRange.endColumn,e.modifiedRange.startLineNumber,e.modifiedRange.startColumn,e.modifiedRange.endLineNumber,e.modifiedRange.endColumn]))]))}return{identical:!(a.changes.length>0)&&this._modelsAreIdentical(e,t),quitEarly:a.hitTimeout,changes:l(a.changes),moves:a.moves.map((e=>[e.lineRangeMapping.original.startLineNumber,e.lineRangeMapping.original.endLineNumberExclusive,e.lineRangeMapping.modified.startLineNumber,e.lineRangeMapping.modified.endLineNumberExclusive,l(e.changes)]))}}static _modelsAreIdentical(e,t){const i=e.getLineCount();if(i!==t.getLineCount())return!1;for(let s=1;s<=i;s++){if(e.getLineContent(s)!==t.getLineContent(s))return!1}return!0}static{this._diffLimit=1e5}async $computeMoreMinimalEdits(e,t,i){const r=this._getModel(e);if(!r)return t;const o=[];let a;t=t.slice(0).sort(((e,t)=>{if(e.range&&t.range)return n.Q.compareRangesUsingStarts(e.range,t.range);return(e.range?0:1)-(t.range?0:1)}));let l=0;for(let s=1;sq._diffLimit){o.push({range:c,text:h});continue}const t=(0,s.F1)(e,h,i),l=r.offsetAt(n.Q.lift(c).getStartPosition());for(const i of t){const e=r.positionAt(l+i.originalStart),t=r.positionAt(l+i.originalStart+i.originalLength),s={text:h.substr(i.modifiedStart,i.modifiedLength),range:{startLineNumber:e.lineNumber,startColumn:e.column,endLineNumber:t.lineNumber,endColumn:t.column}};r.getValueInRange(s.range)!==s.text&&o.push(s)}}return"number"===typeof a&&o.push({eol:a,text:"",range:{startLineNumber:0,startColumn:0,endLineNumber:0,endColumn:0}}),o}async $computeLinks(e){const t=this._getModel(e);return t?function(e){return e&&"function"===typeof e.getLineCount&&"function"===typeof e.getLineContent?h.computeLinks(e):[]}(t):null}async $computeDefaultDocumentColors(e){const t=this._getModel(e);return t?G(t):null}static{this._suggestionsLimit=1e4}async $textualSuggest(e,t,i,s){const n=new p.W,r=new RegExp(i,s),o=new Set;e:for(const a of e){const e=this._getModel(a);if(e)for(const i of e.words(r))if(i!==t&&isNaN(Number(i))&&(o.add(i),o.size>q._suggestionsLimit))break e}return{words:Array.from(o),duration:n.elapsed()}}async $computeWordRanges(e,t,i,s){const n=this._getModel(e);if(!n)return Object.create(null);const r=new RegExp(i,s),o=Object.create(null);for(let a=t.startLineNumber;athis._host.$fhr(e,t))),getMirrorModels:()=>this._getModels()};return this._foreignModuleFactory?(this._foreignModule=this._foreignModuleFactory(n,t),Promise.resolve((0,D.V0)(this._foreignModule))):new Promise(((s,r)=>{const o=e=>{this._foreignModule=e.create(n,t),s((0,D.V0)(this._foreignModule))};{const t=M.zl.asBrowserUri(`${e}.js`).toString(!0);i(9204)(`${t}`).then(o).catch(r)}}))}$fmr(e,t){if(!this._foreignModule||"function"!==typeof this._foreignModule[e])return Promise.reject(new Error("Missing requestHandler or method: "+e));try{return Promise.resolve(this._foreignModule[e].apply(this._foreignModule,t))}catch(i){return Promise.reject(i)}}}function $(e){return new q(g.EditorWorkerHost.getChannel(e),null)}"function"===typeof importScripts&&(globalThis.monaco=(0,u.createMonacoBaseAPI)())},10920:(e,t,i)=>{"use strict";i.r(t),i.d(t,{IEditorWorkerService:()=>s});const s=(0,i(63591).u1)("editorWorkerService")},80718:(e,t,i)=>{"use strict";i.r(t),i.d(t,{EditorWorkerHost:()=>s});class s{static{this.CHANNEL_NAME="editorWorkerHost"}static getChannel(e){return e.getChannel(s.CHANNEL_NAME)}static setChannel(e,t){e.setChannel(s.CHANNEL_NAME,t)}}},56691:(e,t,i)=>{"use strict";i.r(t),i.d(t,{findSectionHeaders:()=>r});const s=new RegExp("\\bMARK:\\s*(.*)$","d"),n=/^-+|-+$/g;function r(e,t){let i=[];if(t.findRegionSectionHeaders&&t.foldingRules?.markers){const s=function(e,t){const i=[],s=e.getLineCount();for(let n=1;n<=s;n++){const s=e.getLineContent(n),r=s.match(t.foldingRules.markers.start);if(r){const e={startLineNumber:n,startColumn:r[0].length+1,endLineNumber:n,endColumn:s.length+1};if(e.endColumn>e.startColumn){const t={range:e,...a(s.substring(r[0].length)),shouldBeInComments:!1};(t.text||t.hasSeparatorLine)&&i.push(t)}}}return i}(e,t);i=i.concat(s)}if(t.findMarkSectionHeaders){const t=function(e){const t=[],i=e.getLineCount();for(let s=1;s<=i;s++){o(e.getLineContent(s),s,t)}return t}(e);i=i.concat(t)}return i}function o(e,t,i){s.lastIndex=0;const n=s.exec(e);if(n){const e={startLineNumber:t,startColumn:n.indices[1][0]+1,endLineNumber:t,endColumn:n.indices[1][1]+1};if(e.endColumn>e.startColumn){const t={range:e,...a(n[1]),shouldBeInComments:!0};(t.text||t.hasSeparatorLine)&&i.push(t)}}}function a(e){const t=(e=e.trim()).startsWith("-");return{text:e=e.replace(n,""),hasSeparatorLine:t}}},53068:(e,t,i)=>{"use strict";i.r(t),i.d(t,{getIconClasses:()=>h});var s=i(36456),n=i(89403),r=i(79400),o=i(83941),a=i(7291),l=i(25689);const c=/(?:\/|^)(?:([^\/]+)\/)?([^\/]+)$/;function h(e,t,i,h,u){if(l.L.isThemeIcon(u))return[`codicon-${u.id}`,"predefined-file-icon"];if(r.r.isUri(u))return[];const g=h===a.p.ROOT_FOLDER?["rootfolder-icon"]:h===a.p.FOLDER?["folder-icon"]:["file-icon"];if(i){let r;if(i.scheme===s.ny.data){r=n.B6.parseMetaData(i).get(n.B6.META_DATA_LABEL)}else{const e=i.path.match(c);e?(r=d(e[2].toLowerCase()),e[1]&&g.push(`${d(e[1].toLowerCase())}-name-dir-icon`)):r=d(i.authority.toLowerCase())}if(h===a.p.ROOT_FOLDER)g.push(`${r}-root-name-folder-icon`);else if(h===a.p.FOLDER)g.push(`${r}-name-folder-icon`);else{if(r){if(g.push(`${r}-name-file-icon`),g.push("name-file-icon"),r.length<=255){const e=r.split(".");for(let t=1;t{"use strict";i.r(t),i.d(t,{ILanguageFeatureDebounceService:()=>g,LanguageFeatureDebounceService:()=>_});var s=i(85600),n=i(74320),r=i(1592),o=i(97035),a=i(14718),l=i(63591),c=i(18801),h=i(36456),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},u=function(e,t){return function(i,s){t(i,s,e)}};const g=(0,l.u1)("ILanguageFeatureDebounceService");var p;!function(e){const t=new WeakMap;let i=0;e.of=function(e){let s=t.get(e);return void 0===s&&(s=++i,t.set(e,s)),s}}(p||(p={}));class m{constructor(e){this._default=e}get(e){return this._default}update(e,t){return this._default}default(){return this._default}}class f{constructor(e,t,i,s,r,o){this._logService=e,this._name=t,this._registry=i,this._default=s,this._min=r,this._max=o,this._cache=new n.qK(50,.7)}_key(e){return e.id+this._registry.all(e).reduce(((e,t)=>(0,s.sN)(p.of(t),e)),0)}get(e){const t=this._key(e),i=this._cache.get(t);return i?(0,r.qE)(i.value,this._min,this._max):this.default()}update(e,t){const i=this._key(e);let s=this._cache.get(i);s||(s=new r.mu(6),this._cache.set(i,s));const n=(0,r.qE)(s.update(t),this._min,this._max);return(0,h.v$)(e.uri,"output")||this._logService.trace(`[DEBOUNCE: ${this._name}] for ${e.uri.toString()} is ${n}ms`),n}_overall(){const e=new r.Uq;for(const[,t]of this._cache)e.update(t.value);return e.value}default(){const e=0|this._overall()||this._default;return(0,r.qE)(e,this._min,this._max)}}let _=class{constructor(e,t){this._logService=e,this._data=new Map,this._isDev=t.isExtensionDevelopment||!t.isBuilt}for(e,t,i){const s=i?.min??50,n=i?.max??s**2,r=i?.key??void 0,o=`${p.of(e)},${s}${r?","+r:""}`;let a=this._data.get(o);return a||(this._isDev?(this._logService.debug(`[DEBOUNCE: ${t}] is disabled in developed mode`),a=new m(1.5*s)):a=new f(this._logService,t,e,0|this._overallAverage()||1.5*s,s,n),this._data.set(o,a)),a}_overallAverage(){const e=new r.Uq;for(const t of this._data.values())e.update(t.default());return e.value}};_=d([u(0,c.rr),u(1,o.k)],_),(0,a.v)(g,_,1)},56942:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ILanguageFeaturesService:()=>s});const s=(0,i(63591).u1)("ILanguageFeaturesService")},76007:(e,t,i)=>{"use strict";i.r(t),i.d(t,{LanguageFeaturesService:()=>g});var s=i(41234),n=i(5662),r=i(16223),o=i(54459);function a(e){return"string"!==typeof e&&(Array.isArray(e)?e.every(a):!!e.exclusive)}class l{constructor(e,t,i,s,n){this.uri=e,this.languageId=t,this.notebookUri=i,this.notebookType=s,this.recursive=n}equals(e){return this.notebookType===e.notebookType&&this.languageId===e.languageId&&this.uri.toString()===e.uri.toString()&&this.notebookUri?.toString()===e.notebookUri?.toString()&&this.recursive===e.recursive}}class c{constructor(e){this._notebookInfoResolver=e,this._clock=0,this._entries=[],this._onDidChange=new s.vl,this.onDidChange=this._onDidChange.event}register(e,t){let i={selector:e,provider:t,_score:-1,_time:this._clock++};return this._entries.push(i),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),(0,n.s)((()=>{if(i){const e=this._entries.indexOf(i);e>=0&&(this._entries.splice(e,1),this._lastCandidate=void 0,this._onDidChange.fire(this._entries.length),i=void 0)}}))}has(e){return this.all(e).length>0}all(e){if(!e)return[];this._updateScores(e,!1);const t=[];for(const i of this._entries)i._score>0&&t.push(i.provider);return t}ordered(e,t=!1){const i=[];return this._orderedForEach(e,t,(e=>i.push(e.provider))),i}orderedGroups(e){const t=[];let i,s;return this._orderedForEach(e,!1,(e=>{i&&s===e._score?i.push(e.provider):(s=e._score,i=[e.provider],t.push(i))})),t}_orderedForEach(e,t,i){this._updateScores(e,t);for(const s of this._entries)s._score>0&&i(s)}_updateScores(e,t){const i=this._notebookInfoResolver?.(e.uri),s=i?new l(e.uri,e.getLanguageId(),i.uri,i.type,t):new l(e.uri,e.getLanguageId(),void 0,void 0,t);if(!this._lastCandidate?.equals(s)){this._lastCandidate=s;for(const i of this._entries)if(i._score=(0,o.f)(i.selector,s.uri,s.languageId,(0,r.vd)(e),s.notebookUri,s.notebookType),a(i.selector)&&i._score>0){if(!t){for(const e of this._entries)e._score=0;i._score=1e3;break}i._score=0}this._entries.sort(c._compareByScoreAndTime)}}static _compareByScoreAndTime(e,t){return e._scoret._score?-1:h(e.selector)&&!h(t.selector)?1:!h(e.selector)&&h(t.selector)?-1:e._timet._time?-1:0}}function h(e){return"string"!==typeof e&&(Array.isArray(e)?e.some(h):Boolean(e.isBuiltin))}var d=i(56942),u=i(14718);class g{constructor(){this.referenceProvider=new c(this._score.bind(this)),this.renameProvider=new c(this._score.bind(this)),this.newSymbolNamesProvider=new c(this._score.bind(this)),this.codeActionProvider=new c(this._score.bind(this)),this.definitionProvider=new c(this._score.bind(this)),this.typeDefinitionProvider=new c(this._score.bind(this)),this.declarationProvider=new c(this._score.bind(this)),this.implementationProvider=new c(this._score.bind(this)),this.documentSymbolProvider=new c(this._score.bind(this)),this.inlayHintsProvider=new c(this._score.bind(this)),this.colorProvider=new c(this._score.bind(this)),this.codeLensProvider=new c(this._score.bind(this)),this.documentFormattingEditProvider=new c(this._score.bind(this)),this.documentRangeFormattingEditProvider=new c(this._score.bind(this)),this.onTypeFormattingEditProvider=new c(this._score.bind(this)),this.signatureHelpProvider=new c(this._score.bind(this)),this.hoverProvider=new c(this._score.bind(this)),this.documentHighlightProvider=new c(this._score.bind(this)),this.multiDocumentHighlightProvider=new c(this._score.bind(this)),this.selectionRangeProvider=new c(this._score.bind(this)),this.foldingRangeProvider=new c(this._score.bind(this)),this.linkProvider=new c(this._score.bind(this)),this.inlineCompletionsProvider=new c(this._score.bind(this)),this.inlineEditProvider=new c(this._score.bind(this)),this.completionProvider=new c(this._score.bind(this)),this.linkedEditingRangeProvider=new c(this._score.bind(this)),this.documentRangeSemanticTokensProvider=new c(this._score.bind(this)),this.documentSemanticTokensProvider=new c(this._score.bind(this)),this.documentDropEditProvider=new c(this._score.bind(this)),this.documentPasteEditProvider=new c(this._score.bind(this))}_score(e){return this._notebookTypeResolver?.(e)}}(0,u.v)(d.ILanguageFeaturesService,g,1)},17890:(e,t,i)=>{"use strict";i.r(t),i.d(t,{LanguageService:()=>h});var s=i(41234),n=i(5662),r=i(69259),o=i(25890),a=i(62083),l=i(83941),c=i(31308);class h extends n.jG{static{this.instanceCount=0}constructor(e=!1){super(),this._onDidRequestBasicLanguageFeatures=this._register(new s.vl),this.onDidRequestBasicLanguageFeatures=this._onDidRequestBasicLanguageFeatures.event,this._onDidRequestRichLanguageFeatures=this._register(new s.vl),this.onDidRequestRichLanguageFeatures=this._onDidRequestRichLanguageFeatures.event,this._onDidChange=this._register(new s.vl({leakWarningThreshold:200})),this.onDidChange=this._onDidChange.event,this._requestedBasicLanguages=new Set,this._requestedRichLanguages=new Set,h.instanceCount++,this._registry=this._register(new r.LanguagesRegistry(!0,e)),this.languageIdCodec=this._registry.languageIdCodec,this._register(this._registry.onDidChange((()=>this._onDidChange.fire())))}dispose(){h.instanceCount--,super.dispose()}isRegisteredLanguageId(e){return this._registry.isRegisteredLanguageId(e)}getLanguageIdByLanguageName(e){return this._registry.getLanguageIdByLanguageName(e)}getLanguageIdByMimeType(e){return this._registry.getLanguageIdByMimeType(e)}guessLanguageIdByFilepathOrFirstLine(e,t){const i=this._registry.guessLanguageIdByFilepathOrFirstLine(e,t);return(0,o.Fy)(i,null)}createById(e){return new d(this.onDidChange,(()=>this._createAndGetLanguageIdentifier(e)))}createByFilepathOrFirstLine(e,t){return new d(this.onDidChange,(()=>{const i=this.guessLanguageIdByFilepathOrFirstLine(e,t);return this._createAndGetLanguageIdentifier(i)}))}_createAndGetLanguageIdentifier(e){return e&&this.isRegisteredLanguageId(e)||(e=l.vH),e}requestBasicLanguageFeatures(e){this._requestedBasicLanguages.has(e)||(this._requestedBasicLanguages.add(e),this._onDidRequestBasicLanguageFeatures.fire(e))}requestRichLanguageFeatures(e){this._requestedRichLanguages.has(e)||(this._requestedRichLanguages.add(e),this.requestBasicLanguageFeatures(e),a.dG.getOrCreate(e),this._onDidRequestRichLanguageFeatures.fire(e))}}class d{constructor(e,t){this._value=(0,c.y0)(this,e,(()=>t())),this.onDidChange=s.Jh.fromObservable(this._value)}get languageId(){return this._value.get()}}},99908:(e,t,i)=>{"use strict";i.r(t),i.d(t,{clearPlatformLanguageAssociations:()=>p,getLanguageIds:()=>m,registerPlatformLanguageAssociation:()=>g});var s=i(46958),n=i(44320),r=i(36456),o=i(74027),a=i(89403),l=i(91508),c=i(83941);let h=[],d=[],u=[];function g(e,t=!1){!function(e,t,i){const n=function(e,t){return{id:e.id,mime:e.mime,filename:e.filename,extension:e.extension,filepattern:e.filepattern,firstline:e.firstline,userConfigured:t,filenameLowercase:e.filename?e.filename.toLowerCase():void 0,extensionLowercase:e.extension?e.extension.toLowerCase():void 0,filepatternLowercase:e.filepattern?(0,s.qg)(e.filepattern.toLowerCase()):void 0,filepatternOnPath:!!e.filepattern&&e.filepattern.indexOf(o.SA.sep)>=0}}(e,t);h.push(n),n.userConfigured?u.push(n):d.push(n);i&&!n.userConfigured&&h.forEach((e=>{e.mime===n.mime||e.userConfigured||(n.extension&&e.extension===n.extension&&console.warn(`Overwriting extension <<${n.extension}>> to now point to mime <<${n.mime}>>`),n.filename&&e.filename===n.filename&&console.warn(`Overwriting filename <<${n.filename}>> to now point to mime <<${n.mime}>>`),n.filepattern&&e.filepattern===n.filepattern&&console.warn(`Overwriting filepattern <<${n.filepattern}>> to now point to mime <<${n.mime}>>`),n.firstline&&e.firstline===n.firstline&&console.warn(`Overwriting firstline <<${n.firstline}>> to now point to mime <<${n.mime}>>`))}))}(e,!1,t)}function p(){h=h.filter((e=>e.userConfigured)),d=[]}function m(e,t){return function(e,t){let i;if(e)switch(e.scheme){case r.ny.file:i=e.fsPath;break;case r.ny.data:i=a.B6.parseMetaData(e).get(a.B6.META_DATA_LABEL);break;case r.ny.vscodeNotebookCell:i=void 0;break;default:i=e.path}if(!i)return[{id:"unknown",mime:n.K.unknown}];i=i.toLowerCase();const s=(0,o.P8)(i),g=f(i,s,u);if(g)return[g,{id:c.vH,mime:n.K.text}];const p=f(i,s,d);if(p)return[p,{id:c.vH,mime:n.K.text}];if(t){const e=function(e){(0,l.LU)(e)&&(e=e.substr(1));if(e.length>0)for(let t=h.length-1;t>=0;t--){const i=h[t];if(!i.firstline)continue;const s=e.match(i.firstline);if(s&&s.length>0)return i}return}(t);if(e)return[e,{id:c.vH,mime:n.K.text}]}return[{id:"unknown",mime:n.K.unknown}]}(e,t).map((e=>e.id))}function f(e,t,i){let s,n,r;for(let o=i.length-1;o>=0;o--){const a=i[o];if(t===a.filenameLowercase){s=a;break}if(a.filepattern&&(!n||a.filepattern.length>n.filepattern.length)){const i=a.filepatternOnPath?e:t;a.filepatternLowercase?.(i)&&(n=a)}a.extension&&(!r||a.extension.length>r.extension.length)&&t.endsWith(a.extensionLowercase)&&(r=a)}return s||(n||(r||void 0))}},69259:(e,t,i)=>{"use strict";i.r(t),i.d(t,{LanguageIdCodec:()=>u,LanguagesRegistry:()=>g});var s=i(41234),n=i(5662),r=i(91508),o=i(99908),a=i(83941),l=i(1646),c=i(46359);const h=Object.prototype.hasOwnProperty,d="vs.editor.nullLanguage";class u{constructor(){this._languageIdToLanguage=[],this._languageToLanguageId=new Map,this._register(d,0),this._register(a.vH,1),this._nextLanguageId=2}_register(e,t){this._languageIdToLanguage[t]=e,this._languageToLanguageId.set(e,t)}register(e){if(this._languageToLanguageId.has(e))return;const t=this._nextLanguageId++;this._register(e,t)}encodeLanguageId(e){return this._languageToLanguageId.get(e)||0}decodeLanguageId(e){return this._languageIdToLanguage[e]||d}}class g extends n.jG{static{this.instanceCount=0}constructor(e=!0,t=!1){super(),this._onDidChange=this._register(new s.vl),this.onDidChange=this._onDidChange.event,g.instanceCount++,this._warnOnOverwrite=t,this.languageIdCodec=new u,this._dynamicLanguages=[],this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},e&&(this._initializeFromRegistry(),this._register(a.W6.onDidChangeLanguages((e=>{this._initializeFromRegistry()}))))}dispose(){g.instanceCount--,super.dispose()}_initializeFromRegistry(){this._languages={},this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},(0,o.clearPlatformLanguageAssociations)();const e=[].concat(a.W6.getLanguages()).concat(this._dynamicLanguages);this._registerLanguages(e)}_registerLanguages(e){for(const t of e)this._registerLanguage(t);this._mimeTypesMap={},this._nameMap={},this._lowercaseNameMap={},Object.keys(this._languages).forEach((e=>{const t=this._languages[e];t.name&&(this._nameMap[t.name]=t.identifier),t.aliases.forEach((e=>{this._lowercaseNameMap[e.toLowerCase()]=t.identifier})),t.mimetypes.forEach((e=>{this._mimeTypesMap[e]=t.identifier}))})),c.O.as(l.Fd.Configuration).registerOverrideIdentifiers(this.getRegisteredLanguageIds()),this._onDidChange.fire()}_registerLanguage(e){const t=e.id;let i;h.call(this._languages,t)?i=this._languages[t]:(this.languageIdCodec.register(t),i={identifier:t,name:null,mimetypes:[],aliases:[],extensions:[],filenames:[],configurationFiles:[],icons:[]},this._languages[t]=i),this._mergeLanguage(i,e)}_mergeLanguage(e,t){const i=t.id;let s=null;if(Array.isArray(t.mimetypes)&&t.mimetypes.length>0&&(e.mimetypes.push(...t.mimetypes),s=t.mimetypes[0]),s||(s=`text/x-${i}`,e.mimetypes.push(s)),Array.isArray(t.extensions)){t.configuration?e.extensions=t.extensions.concat(e.extensions):e.extensions=e.extensions.concat(t.extensions);for(const e of t.extensions)(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,extension:e},this._warnOnOverwrite)}if(Array.isArray(t.filenames))for(const r of t.filenames)(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,filename:r},this._warnOnOverwrite),e.filenames.push(r);if(Array.isArray(t.filenamePatterns))for(const r of t.filenamePatterns)(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,filepattern:r},this._warnOnOverwrite);if("string"===typeof t.firstLine&&t.firstLine.length>0){let e=t.firstLine;"^"!==e.charAt(0)&&(e="^"+e);try{const t=new RegExp(e);(0,r.eY)(t)||(0,o.registerPlatformLanguageAssociation)({id:i,mime:s,firstline:t},this._warnOnOverwrite)}catch(l){console.warn(`[${t.id}]: Invalid regular expression \`${e}\`: `,l)}}e.aliases.push(i);let n=null;if("undefined"!==typeof t.aliases&&Array.isArray(t.aliases)&&(n=0===t.aliases.length?[null]:t.aliases),null!==n)for(const r of n)r&&0!==r.length&&e.aliases.push(r);const a=null!==n&&n.length>0;if(a&&null===n[0]);else{const t=(a?n[0]:null)||i;!a&&e.name||(e.name=t)}t.configuration&&e.configurationFiles.push(t.configuration),t.icon&&e.icons.push(t.icon)}isRegisteredLanguageId(e){return!!e&&h.call(this._languages,e)}getRegisteredLanguageIds(){return Object.keys(this._languages)}getLanguageIdByLanguageName(e){const t=e.toLowerCase();return h.call(this._lowercaseNameMap,t)?this._lowercaseNameMap[t]:null}getLanguageIdByMimeType(e){return e&&h.call(this._mimeTypesMap,e)?this._mimeTypesMap[e]:null}guessLanguageIdByFilepathOrFirstLine(e,t){return e||t?(0,o.getLanguageIds)(e,t):[]}}},37550:(e,t,i)=>{"use strict";i.r(t),i.d(t,{IMarkerDecorationsService:()=>s});const s=(0,i(63591).u1)("markerDecorationsService")},30707:(e,t,i)=>{"use strict";i.r(t),i.d(t,{MarkerDecorationsService:()=>_});var s=i(75147),n=i(5662),r=i(16223),o=i(47612),a=i(87119),l=i(23750),c=i(36677),h=i(36456),d=i(41234),u=i(66261),g=i(74320),p=i(48495),m=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},f=function(e,t){return function(i,s){t(i,s,e)}};let _=class extends n.jG{constructor(e,t){super(),this._markerService=t,this._onDidChangeMarker=this._register(new d.vl),this._markerDecorations=new g.fT,e.getModels().forEach((e=>this._onModelAdded(e))),this._register(e.onModelAdded(this._onModelAdded,this)),this._register(e.onModelRemoved(this._onModelRemoved,this)),this._register(this._markerService.onMarkerChanged(this._handleMarkerChange,this))}dispose(){super.dispose(),this._markerDecorations.forEach((e=>e.dispose())),this._markerDecorations.clear()}getMarker(e,t){const i=this._markerDecorations.get(e);return i&&i.getMarker(t)||null}_handleMarkerChange(e){e.forEach((e=>{const t=this._markerDecorations.get(e);t&&this._updateDecorations(t)}))}_onModelAdded(e){const t=new v(e);this._markerDecorations.set(e.uri,t),this._updateDecorations(t)}_onModelRemoved(e){const t=this._markerDecorations.get(e.uri);t&&(t.dispose(),this._markerDecorations.delete(e.uri)),e.uri.scheme!==h.ny.inMemory&&e.uri.scheme!==h.ny.internal&&e.uri.scheme!==h.ny.vscode||this._markerService?.read({resource:e.uri}).map((e=>e.owner)).forEach((t=>this._markerService.remove(t,[e.uri])))}_updateDecorations(e){const t=this._markerService.read({resource:e.model.uri,take:500});e.update(t)&&this._onDidChangeMarker.fire(e.model)}};_=m([f(0,l.IModelService),f(1,s.DR)],_);class v extends n.jG{constructor(e){super(),this.model=e,this._map=new g.cO,this._register((0,n.s)((()=>{this.model.deltaDecorations([...this._map.values()],[]),this._map.clear()})))}update(e){const{added:t,removed:i}=(0,p.Z)(new Set(this._map.keys()),new Set(e));if(0===t.length&&0===i.length)return!1;const s=i.map((e=>this._map.get(e))),n=t.map((e=>({range:this._createDecorationRange(this.model,e),options:this._createDecorationOption(e)}))),r=this.model.deltaDecorations(s,n);for(const o of i)this._map.delete(o);for(let o=0;o=t)return i;const s=e.getWordAtPosition(i.getStartPosition());s&&(i=new c.Q(i.startLineNumber,s.startColumn,i.endLineNumber,s.endColumn))}else if(t.endColumn===Number.MAX_VALUE&&1===t.startColumn&&i.startLineNumber===i.endLineNumber){const s=e.getLineFirstNonWhitespaceColumn(t.startLineNumber);s=0}}},23750:(e,t,i)=>{"use strict";i.r(t),i.d(t,{IModelService:()=>s});const s=(0,i(63591).u1)("modelService")},16363:(e,t,i)=>{"use strict";i.r(t),i.d(t,{DefaultModelSHA1Computer:()=>L,ModelService:()=>w});var s,n=i(41234),r=i(5662),o=i(98067),a=i(87289),l=i(24329),c=i(83941),h=i(90360),d=i(84001),u=i(47579),g=i(85600),p=i(26656),m=i(36456),f=i(10146),_=i(63591),v=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},C=function(e,t){return function(i,s){t(i,s,e)}};function b(e){return e.toString()}class E{constructor(e,t,i){this.model=e,this._modelEventListeners=new r.Cm,this.model=e,this._modelEventListeners.add(e.onWillDispose((()=>t(e)))),this._modelEventListeners.add(e.onDidChangeLanguage((t=>i(e,t))))}dispose(){this._modelEventListeners.dispose()}}const S=o.j9||o.zx?1:2;class y{constructor(e,t,i,s,n,r,o,a){this.uri=e,this.initialUndoRedoSnapshot=t,this.time=i,this.sharesUndoRedoStack=s,this.heapSize=n,this.sha1=r,this.versionId=o,this.alternativeVersionId=a}}let w=class extends r.jG{static{s=this}static{this.MAX_MEMORY_FOR_CLOSED_FILES_UNDO_STACK=20971520}constructor(e,t,i,s){super(),this._configurationService=e,this._resourcePropertiesService=t,this._undoRedoService=i,this._instantiationService=s,this._onModelAdded=this._register(new n.vl),this.onModelAdded=this._onModelAdded.event,this._onModelRemoved=this._register(new n.vl),this.onModelRemoved=this._onModelRemoved.event,this._onModelModeChanged=this._register(new n.vl),this.onModelLanguageChanged=this._onModelModeChanged.event,this._modelCreationOptionsByLanguageAndResource=Object.create(null),this._models={},this._disposedModels=new Map,this._disposedModelsHeapSize=0,this._register(this._configurationService.onDidChangeConfiguration((e=>this._updateModelOptions(e)))),this._updateModelOptions(void 0)}static _readModelOptions(e,t){let i=l.R.tabSize;if(e.editor&&"undefined"!==typeof e.editor.tabSize){const t=parseInt(e.editor.tabSize,10);isNaN(t)||(i=t),i<1&&(i=1)}let s="tabSize";if(e.editor&&"undefined"!==typeof e.editor.indentSize&&"tabSize"!==e.editor.indentSize){const t=parseInt(e.editor.indentSize,10);isNaN(t)||(s=Math.max(t,1))}let n=l.R.insertSpaces;e.editor&&"undefined"!==typeof e.editor.insertSpaces&&(n="false"!==e.editor.insertSpaces&&Boolean(e.editor.insertSpaces));let r=S;const o=e.eol;"\r\n"===o?r=2:"\n"===o&&(r=1);let a=l.R.trimAutoWhitespace;e.editor&&"undefined"!==typeof e.editor.trimAutoWhitespace&&(a="false"!==e.editor.trimAutoWhitespace&&Boolean(e.editor.trimAutoWhitespace));let c=l.R.detectIndentation;e.editor&&"undefined"!==typeof e.editor.detectIndentation&&(c="false"!==e.editor.detectIndentation&&Boolean(e.editor.detectIndentation));let h=l.R.largeFileOptimizations;e.editor&&"undefined"!==typeof e.editor.largeFileOptimizations&&(h="false"!==e.editor.largeFileOptimizations&&Boolean(e.editor.largeFileOptimizations));let d=l.R.bracketPairColorizationOptions;return e.editor?.bracketPairColorization&&"object"===typeof e.editor.bracketPairColorization&&(d={enabled:!!e.editor.bracketPairColorization.enabled,independentColorPoolPerBracketType:!!e.editor.bracketPairColorization.independentColorPoolPerBracketType}),{isForSimpleWidget:t,tabSize:i,indentSize:s,insertSpaces:n,detectIndentation:c,defaultEOL:r,trimAutoWhitespace:a,largeFileOptimizations:h,bracketPairColorizationOptions:d}}_getEOL(e,t){if(e)return this._resourcePropertiesService.getEOL(e,t);const i=this._configurationService.getValue("files.eol",{overrideIdentifier:t});return i&&"string"===typeof i&&"auto"!==i?i:3===o.OS||2===o.OS?"\n":"\r\n"}_shouldRestoreUndoStack(){const e=this._configurationService.getValue("files.restoreUndoStack");return"boolean"!==typeof e||e}getCreationOptions(e,t,i){const n="string"===typeof e?e:e.languageId;let r=this._modelCreationOptionsByLanguageAndResource[n+t];if(!r){const e=this._configurationService.getValue("editor",{overrideIdentifier:n,resource:t}),o=this._getEOL(t,n);r=s._readModelOptions({editor:e,eol:o},i),this._modelCreationOptionsByLanguageAndResource[n+t]=r}return r}_updateModelOptions(e){const t=this._modelCreationOptionsByLanguageAndResource;this._modelCreationOptionsByLanguageAndResource=Object.create(null);const i=Object.keys(this._models);for(let n=0,r=i.length;ne){const t=[];for(this._disposedModels.forEach((e=>{e.sharesUndoRedoStack||t.push(e)})),t.sort(((e,t)=>e.time-t.time));t.length>0&&this._disposedModelsHeapSize>e;){const e=t.shift();this._removeDisposedModel(e.uri),null!==e.initialUndoRedoSnapshot&&this._undoRedoService.restoreSnapshot(e.initialUndoRedoSnapshot)}}}_createModelData(e,t,i,s){const n=this.getCreationOptions(t,i,s),r=this._instantiationService.createInstance(a.Bz,e,t,n,i);if(i&&this._disposedModels.has(b(i))){const e=this._removeDisposedModel(i),t=this._undoRedoService.getElements(i),s=this._getSHA1Computer(),n=!!s.canComputeSHA1(r)&&s.computeSHA1(r)===e.sha1;if(n||e.sharesUndoRedoStack){for(const e of t.past)(0,p.Th)(e)&&e.matchesResource(i)&&e.setModel(r);for(const e of t.future)(0,p.Th)(e)&&e.matchesResource(i)&&e.setModel(r);this._undoRedoService.setElementsValidFlag(i,!0,(e=>(0,p.Th)(e)&&e.matchesResource(i))),n&&(r._overwriteVersionId(e.versionId),r._overwriteAlternativeVersionId(e.alternativeVersionId),r._overwriteInitialUndoRedoSnapshot(e.initialUndoRedoSnapshot))}else null!==e.initialUndoRedoSnapshot&&this._undoRedoService.restoreSnapshot(e.initialUndoRedoSnapshot)}const o=b(r.uri);if(this._models[o])throw new Error("ModelService: Cannot add model because it already exists!");const l=new E(r,(e=>this._onWillDispose(e)),((e,t)=>this._onDidChangeLanguage(e,t)));return this._models[o]=l,l}createModel(e,t,i,s=!1){let n;return n=t?this._createModelData(e,t,i,s):this._createModelData(e,c.vH,i,s),this._onModelAdded.fire(n.model),n.model}getModels(){const e=[],t=Object.keys(this._models);for(let i=0,s=t.length;i0||t.future.length>0){for(const i of t.past)(0,p.Th)(i)&&i.matchesResource(e.uri)&&(r=!0,o+=i.heapSize(e.uri),i.setModel(e.uri));for(const i of t.future)(0,p.Th)(i)&&i.matchesResource(e.uri)&&(r=!0,o+=i.heapSize(e.uri),i.setModel(e.uri))}}const a=s.MAX_MEMORY_FOR_CLOSED_FILES_UNDO_STACK,l=this._getSHA1Computer();if(r)if(n||!(o>a)&&l.canComputeSHA1(e))this._ensureDisposedModelsHeapSize(a-o),this._undoRedoService.setElementsValidFlag(e.uri,!1,(t=>(0,p.Th)(t)&&t.matchesResource(e.uri))),this._insertDisposedModel(new y(e.uri,i.model.getInitialUndoRedoSnapshot(),Date.now(),n,o,l.computeSHA1(e),e.getVersionId(),e.getAlternativeVersionId()));else{const e=i.model.getInitialUndoRedoSnapshot();null!==e&&this._undoRedoService.restoreSnapshot(e)}else if(!n){const e=i.model.getInitialUndoRedoSnapshot();null!==e&&this._undoRedoService.restoreSnapshot(e)}delete this._models[t],i.dispose(),delete this._modelCreationOptionsByLanguageAndResource[e.getLanguageId()+e.uri],this._onModelRemoved.fire(e)}_onDidChangeLanguage(e,t){const i=t.oldLanguage,n=e.getLanguageId(),r=this.getCreationOptions(i,e.uri,e.isForSimpleWidget),o=this.getCreationOptions(n,e.uri,e.isForSimpleWidget);s._setModelOptionsForModel(e,o,r),this._onModelModeChanged.fire({model:e,oldLanguageId:i})}_getSHA1Computer(){return new L}};w=s=v([C(0,d.pG),C(1,h.ITextResourcePropertiesService),C(2,u.$D),C(3,_._Y)],w);class L{static{this.MAX_MODEL_SIZE=10485760}canComputeSHA1(e){return e.getValueLength()<=L.MAX_MODEL_SIZE}computeSHA1(e){const t=new g.v7,i=e.createSnapshot();let s;for(;s=i.read();)t.update(s);return t.digest()}}},18938:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ITextModelService:()=>s});const s=(0,i(63591).u1)("textModelService")},98232:(e,t,i)=>{"use strict";i.r(t),i.d(t,{encodeSemanticTokensDto:()=>r});var s=i(81674),n=i(98067);function r(e){const t=new Uint32Array(function(e){let t=0;if(t+=2,"full"===e.type)t+=1+e.data.length;else{t+=1,t+=3*e.deltas.length;for(const i of e.deltas)i.data&&(t+=i.data.length)}return t}(e));let i=0;if(t[i++]=e.id,"full"===e.type)t[i++]=1,t[i++]=e.data.length,t.set(e.data,i),i+=e.data.length;else{t[i++]=2,t[i++]=e.deltas.length;for(const s of e.deltas)t[i++]=s.start,t[i++]=s.deleteCount,s.data?(t[i++]=s.data.length,t.set(s.data,i),i+=s.data.length):t[i++]=0}return function(e){const t=new Uint8Array(e.buffer,e.byteOffset,4*e.length);return n.cm()||function(e){for(let t=0,i=e.length;t{"use strict";i.r(t),i.d(t,{SemanticTokensProviderStyling:()=>m,toMultilineTokens2:()=>f});i(25982);var s=i(47612),n=i(18801),r=i(83069),o=i(36677),a=i(64454);class l{static create(e,t){return new l(e,new c(t))}get startLineNumber(){return this._startLineNumber}get endLineNumber(){return this._endLineNumber}constructor(e,t){this._startLineNumber=e,this._tokens=t,this._endLineNumber=this._startLineNumber+this._tokens.getMaxDeltaLine()}toString(){return this._tokens.toString(this._startLineNumber)}_updateEndLineNumber(){this._endLineNumber=this._startLineNumber+this._tokens.getMaxDeltaLine()}isEmpty(){return this._tokens.isEmpty()}getLineTokens(e){return this._startLineNumber<=e&&e<=this._endLineNumber?this._tokens.getLineTokens(e-this._startLineNumber):null}getRange(){const e=this._tokens.getRange();return e?new o.Q(this._startLineNumber+e.startLineNumber,e.startColumn,this._startLineNumber+e.endLineNumber,e.endColumn):e}removeTokens(e){const t=e.startLineNumber-this._startLineNumber,i=e.endLineNumber-this._startLineNumber;this._startLineNumber+=this._tokens.removeTokens(t,e.startColumn-1,i,e.endColumn-1),this._updateEndLineNumber()}split(e){const t=e.startLineNumber-this._startLineNumber,i=e.endLineNumber-this._startLineNumber,[s,n,r]=this._tokens.split(t,e.startColumn-1,i,e.endColumn-1);return[new l(this._startLineNumber,s),new l(this._startLineNumber+r,n)]}applyEdit(e,t){const[i,s,n]=(0,a.W)(t);this.acceptEdit(e,i,s,n,t.length>0?t.charCodeAt(0):0)}acceptEdit(e,t,i,s,n){this._acceptDeleteRange(e),this._acceptInsertText(new r.y(e.startLineNumber,e.startColumn),t,i,s,n),this._updateEndLineNumber()}_acceptDeleteRange(e){if(e.startLineNumber===e.endLineNumber&&e.startColumn===e.endColumn)return;const t=e.startLineNumber-this._startLineNumber,i=e.endLineNumber-this._startLineNumber;if(i<0){const e=i-t;return void(this._startLineNumber-=e)}const s=this._tokens.getMaxDeltaLine();if(!(t>=s+1)){if(t<0&&i>=s+1)return this._startLineNumber=0,void this._tokens.clear();if(t<0){const s=-t;this._startLineNumber-=s,this._tokens.acceptDeleteRange(e.startColumn-1,0,0,i,e.endColumn-1)}else this._tokens.acceptDeleteRange(0,t,e.startColumn-1,i,e.endColumn-1)}}_acceptInsertText(e,t,i,s,n){if(0===t&&0===i)return;const r=e.lineNumber-this._startLineNumber;if(r<0)return void(this._startLineNumber+=t);r>=this._tokens.getMaxDeltaLine()+1||this._tokens.acceptInsertText(r,e.column-1,t,i,s,n)}}class c{constructor(e){this._tokens=e,this._tokenCount=e.length/4}toString(e){const t=[];for(let i=0;ie)){let n=s;for(;n>t&&this._getDeltaLine(n-1)===e;)n--;let r=s;for(;re||h===e&&u>=t)&&(he||o===e&&g>=t){if(on?p-=n-i:p=i;else if(u===t&&g===i){if(!(u===s&&p>n)){c=!0;continue}p-=n-i}else if(un)){c=!0;continue}u=t,g=i,p=g+(p-n)}else if(u>s){if(0===a&&!c){l=o;break}u-=a}else{if(!(u===s&&g>=n))throw new Error("Not possible!");e&&0===u&&(g+=e,p+=e),u-=a,g-=n-i,p-=n-i}const f=4*l;r[f]=u,r[f+1]=g,r[f+2]=p,r[f+3]=m,l++}this._tokenCount=l}acceptInsertText(e,t,i,s,n,r){const o=0===i&&1===s&&(r>=48&&r<=57||r>=65&&r<=90||r>=97&&r<=122),a=this._tokens,l=this._tokenCount;for(let c=0;c=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};const p=!1;let m=class{constructor(e,t,i,s){this._legend=e,this._themeService=t,this._languageService=i,this._logService=s,this._hasWarnedOverlappingTokens=!1,this._hasWarnedInvalidLengthTokens=!1,this._hasWarnedInvalidEditStart=!1,this._hashTable=new v}getMetadata(e,t,i){const s=this._languageService.languageIdCodec.encodeLanguageId(i),n=this._hashTable.get(e,t,s);let r;if(n)r=n.metadata;else{let n=this._legend.tokenTypes[e];const o=[];if(n){let e=t;for(let t=0;e>0&&t>=1;p;const s=this._themeService.getColorTheme().getTokenStyleMetadata(n,o,i);if("undefined"===typeof s)r=2147483647;else{if(r=0,"undefined"!==typeof s.italic){r|=1|(s.italic?1:0)<<11}if("undefined"!==typeof s.bold){r|=2|(s.bold?2:0)<<11}if("undefined"!==typeof s.underline){r|=4|(s.underline?4:0)<<11}if("undefined"!==typeof s.strikethrough){r|=8|(s.strikethrough?8:0)<<11}if(s.foreground){r|=16|s.foreground<<15}0===r&&(r=2147483647)}}else r=2147483647,n="not-in-legend";this._hashTable.add(e,t,s,r)}return r}warnOverlappingSemanticTokens(e,t){this._hasWarnedOverlappingTokens||(this._hasWarnedOverlappingTokens=!0,this._logService.warn(`Overlapping semantic tokens detected at lineNumber ${e}, column ${t}`))}warnInvalidLengthSemanticTokens(e,t){this._hasWarnedInvalidLengthTokens||(this._hasWarnedInvalidLengthTokens=!0,this._logService.warn(`Semantic token with invalid length detected at lineNumber ${e}, column ${t}`))}warnInvalidEditStart(e,t,i,s,n){this._hasWarnedInvalidEditStart||(this._hasWarnedInvalidEditStart=!0,this._logService.warn(`Invalid semantic tokens edit detected (previousResultId: ${e}, resultId: ${t}) at edit #${i}: The provided start offset ${s} is outside the previous data (length ${n}).`))}};function f(e,t,i){const s=e.data,n=e.data.length/5|0,r=Math.max(Math.ceil(n/1024),400),o=[];let a=0,c=1,h=0;for(;ae&&0===s[5*t];)t--;if(t-1===e){let e=d;for(;e+1l)t.warnOverlappingSemanticTokens(o,l+1);else{const e=t.getMetadata(_,v,i);2147483647!==e&&(0===p&&(p=o),u[g]=o-p,u[g+1]=l,u[g+2]=d,u[g+3]=e,g+=4,m=o,f=d)}c=o,h=l,a++}g!==u.length&&(u=u.subarray(0,g));const _=l.create(p,u);o.push(_)}return o}m=u([g(1,s.Gy),g(2,d.L),g(3,n.rr)],m);class _{constructor(e,t,i,s){this.tokenTypeIndex=e,this.tokenModifierSet=t,this.languageId=i,this.metadata=s,this.next=null}}class v{static{this._SIZES=[3,7,13,31,61,127,251,509,1021,2039,4093,8191,16381,32749,65521,131071,262139,524287,1048573,2097143]}constructor(){this._elementsCount=0,this._currentLengthIndex=0,this._currentLength=v._SIZES[this._currentLengthIndex],this._growCount=Math.round(this._currentLengthIndex+1=this._growCount){const e=this._elements;this._currentLengthIndex++,this._currentLength=v._SIZES[this._currentLengthIndex],this._growCount=Math.round(this._currentLengthIndex+1{"use strict";i.r(t),i.d(t,{ISemanticTokensStylingService:()=>s});const s=(0,i(63591).u1)("semanticTokensStylingService")},27004:(e,t,i)=>{"use strict";i.r(t),i.d(t,{SemanticTokensStylingService:()=>u});var s=i(5662),n=i(10154),r=i(47612),o=i(18801),a=i(45538),l=i(74243),c=i(14718),h=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},d=function(e,t){return function(i,s){t(i,s,e)}};let u=class extends s.jG{constructor(e,t,i){super(),this._themeService=e,this._logService=t,this._languageService=i,this._caches=new WeakMap,this._register(this._themeService.onDidColorThemeChange((()=>{this._caches=new WeakMap})))}getStyling(e){return this._caches.has(e)||this._caches.set(e,new a.SemanticTokensProviderStyling(e.getLegend(),this._themeService,this._languageService,this._logService)),this._caches.get(e)}};u=h([d(0,r.Gy),d(1,o.rr),d(2,n.L)],u),(0,c.v)(l.ISemanticTokensStylingService,u,1)},47443:(e,t,i)=>{"use strict";i.r(t),i.d(t,{MirrorModel:()=>m,STOP_SYNC_MODEL_DELTA_TIME_MS:()=>u,WorkerTextModelSyncClient:()=>g,WorkerTextModelSyncServer:()=>p});var s=i(90766),n=i(5662),r=i(79400),o=i(83069),a=i(36677),l=i(26486),c=i(91508),h=i(27414);class d{constructor(e,t,i,s){this._uri=e,this._lines=t,this._eol=i,this._versionId=s,this._lineStarts=null,this._cachedTextValue=null}dispose(){this._lines.length=0}get version(){return this._versionId}getText(){return null===this._cachedTextValue&&(this._cachedTextValue=this._lines.join(this._eol)),this._cachedTextValue}onEvents(e){e.eol&&e.eol!==this._eol&&(this._eol=e.eol,this._lineStarts=null);const t=e.changes;for(const i of t)this._acceptDeleteRange(i.range),this._acceptInsertText(new o.y(i.range.startLineNumber,i.range.startColumn),i.text);this._versionId=e.versionId,this._cachedTextValue=null}_ensureLineStarts(){if(!this._lineStarts){const e=this._eol.length,t=this._lines.length,i=new Uint32Array(t);for(let s=0;sthis._checkStopModelSync()),Math.round(u/2)),this._register(e)}}dispose(){for(const e in this._syncedModels)(0,n.AS)(this._syncedModels[e]);this._syncedModels=Object.create(null),this._syncedModelsLastUsedTime=Object.create(null),super.dispose()}ensureSyncedResources(e,t=!1){for(const i of e){const e=i.toString();this._syncedModels[e]||this._beginModelSync(i,t),this._syncedModels[e]&&(this._syncedModelsLastUsedTime[e]=(new Date).getTime())}}_checkStopModelSync(){const e=(new Date).getTime(),t=[];for(const i in this._syncedModelsLastUsedTime){e-this._syncedModelsLastUsedTime[i]>u&&t.push(i)}for(const i of t)this._stopModelSync(i)}_beginModelSync(e,t){const i=this._modelService.getModel(e);if(!i)return;if(!t&&i.isTooLargeForSyncing())return;const s=e.toString();this._proxy.$acceptNewModel({url:i.uri.toString(),lines:i.getLinesContent(),EOL:i.getEOL(),versionId:i.getVersionId()});const r=new n.Cm;r.add(i.onDidChangeContent((e=>{this._proxy.$acceptModelChanged(s.toString(),e)}))),r.add(i.onWillDispose((()=>{this._stopModelSync(s)}))),r.add((0,n.s)((()=>{this._proxy.$acceptRemovedModel(s)}))),this._syncedModels[s]=r}_stopModelSync(e){const t=this._syncedModels[e];delete this._syncedModels[e],delete this._syncedModelsLastUsedTime[e],(0,n.AS)(t)}}class p{constructor(){this._models=Object.create(null)}getModel(e){return this._models[e]}getModels(){const e=[];return Object.keys(this._models).forEach((t=>e.push(this._models[t]))),e}$acceptNewModel(e){this._models[e.url]=new m(r.r.parse(e.url),e.lines,e.EOL,e.versionId)}$acceptModelChanged(e,t){if(!this._models[e])return;this._models[e].onEvents(t)}$acceptRemovedModel(e){this._models[e]&&delete this._models[e]}}class m extends d{get uri(){return this._uri}get eol(){return this._eol}getValue(){return this.getText()}findMatches(e){const t=[];for(let i=0;ithis._lines.length)t=this._lines.length,i=this._lines[t-1].length+1,s=!0;else{const e=this._lines[t-1].length+1;i<1?(i=1,s=!0):i>e&&(i=e,s=!0)}return s?{lineNumber:t,column:i}:e}}},90360:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ITextResourceConfigurationService:()=>n,ITextResourcePropertiesService:()=>r});var s=i(63591);const n=(0,s.u1)("textResourceConfigurationService"),r=(0,s.u1)("textResourcePropertiesService")},44432:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ITreeSitterParserService:()=>s});const s=(0,i(63591).u1)("treeSitterParserService")},36723:(e,t,i)=>{"use strict";i.r(t),i.d(t,{DraggedTreeItemsIdentifier:()=>n,TreeViewsDnDService:()=>s});class s{constructor(){this._dragOperations=new Map}removeDragOperationTransfer(e){if(e&&this._dragOperations.has(e)){const t=this._dragOperations.get(e);return this._dragOperations.delete(e),t}}}class n{constructor(e){this.identifier=e}}},29100:(e,t,i)=>{"use strict";i.r(t),i.d(t,{ITreeViewsDnDService:()=>o});var s=i(14718),n=i(63591),r=i(36723);const o=(0,n.u1)("treeViewsDndService");(0,s.v)(o,r.TreeViewsDnDService,1)},74855:(e,t,i)=>{"use strict";i.r(t),i.d(t,{UnicodeTextModelHighlighter:()=>l});var s=i(36677),n=i(43264),r=i(91508),o=i(66782),a=i(26486);class l{static computeUnicodeHighlights(e,t,i){const l=i?i.startLineNumber:1,h=i?i.endLineNumber:e.getLineCount(),d=new c(t),u=d.getCandidateCodePoints();let g;var p;g="allNonBasicAscii"===u?new RegExp("[^\\t\\n\\r\\x20-\\x7E]","g"):new RegExp(""+(p=Array.from(u),`[${r.bm(p.map((e=>String.fromCodePoint(e))).join(""))}]`),"g");const m=new n.W5(null,g),f=[];let _,v=!1,C=0,b=0,E=0;e:for(let n=l,c=h;n<=c;n++){const t=e.getLineContent(n),i=t.length;m.reset(0);do{if(_=m.next(t),_){let e=_.index,l=_.index+_[0].length;if(e>0){const i=t.charCodeAt(e-1);r.pc(i)&&e--}if(l+1=t){v=!0;break e}f.push(new s.Q(n,e+1,n,l+1))}}}while(_)}return{ranges:f,hasMore:v,ambiguousCharacterCount:C,invisibleCharacterCount:b,nonBasicAsciiCharacterCount:E}}static computeUnicodeHighlightReason(e,t){const i=new c(t);switch(i.shouldHighlightNonBasicASCII(e,null)){case 0:return null;case 2:return{kind:1};case 3:{const s=e.codePointAt(0),n=i.ambiguousCharacters.getPrimaryConfusable(s),o=r.tl.getLocales().filter((e=>!r.tl.getInstance(new Set([...t.allowedLocales,e])).isAmbiguous(s)));return{kind:0,confusableWith:String.fromCodePoint(n),notAmbiguousInLocales:o}}case 1:return{kind:2}}}}class c{constructor(e){this.options=e,this.allowedCodePoints=new Set(e.allowedCodePoints),this.ambiguousCharacters=r.tl.getInstance(new Set(e.allowedLocales))}getCandidateCodePoints(){if(this.options.nonBasicASCII)return"allNonBasicAscii";const e=new Set;if(this.options.invisibleCharacters)for(const t of r.y_.codePoints)h(String.fromCodePoint(t))||e.add(t);if(this.options.ambiguousCharacters)for(const t of this.ambiguousCharacters.getConfusableCodePoints())e.add(t);for(const t of this.allowedCodePoints)e.delete(t);return e}shouldHighlightNonBasicASCII(e,t){const i=e.codePointAt(0);if(this.allowedCodePoints.has(i))return 0;if(this.options.nonBasicASCII)return 1;let s=!1,n=!1;if(t)for(const o of t){const e=o.codePointAt(0),t=r.aC(o);s=s||t,t||this.ambiguousCharacters.isAmbiguous(e)||r.y_.isInvisibleCharacter(e)||(n=!0)}return!s&&n?0:this.options.invisibleCharacters&&!h(e)&&r.y_.isInvisibleCharacter(i)?2:this.options.ambiguousCharacters&&this.ambiguousCharacters.isAmbiguous(i)?3:0}}function h(e){return" "===e||"\n"===e||"\t"===e}},35015:(e,t,i)=>{"use strict";var s,n,r,o,a,l,c,h,d,u,g,p,m,f,_,v,C,b,E,S,y,w,L,R,T,x,k,A,N,I,O,D,M,P,F,U,H,B,W,V,z,G,j,K,Y,q;i.d(t,{A5:()=>O,Ah:()=>D,DD:()=>w,DO:()=>P,Gn:()=>s,H_:()=>G,Ic:()=>M,Io:()=>o,Kb:()=>u,M$:()=>v,OV:()=>A,QP:()=>a,Qj:()=>c,R3:()=>T,SB:()=>B,U7:()=>j,VW:()=>b,VX:()=>x,WA:()=>V,WU:()=>f,XR:()=>H,YT:()=>N,ZS:()=>_,_E:()=>r,cj:()=>L,dE:()=>I,d_:()=>R,e0:()=>g,h5:()=>h,hS:()=>k,hW:()=>F,jT:()=>W,kK:()=>Y,kf:()=>m,l:()=>C,m9:()=>K,of:()=>d,ok:()=>n,ov:()=>U,p2:()=>p,qw:()=>S,r4:()=>E,sm:()=>y,t7:()=>l,tJ:()=>q,v0:()=>z}),function(e){e[e.Unknown=0]="Unknown",e[e.Disabled=1]="Disabled",e[e.Enabled=2]="Enabled"}(s||(s={})),function(e){e[e.Invoke=1]="Invoke",e[e.Auto=2]="Auto"}(n||(n={})),function(e){e[e.None=0]="None",e[e.KeepWhitespace=1]="KeepWhitespace",e[e.InsertAsSnippet=4]="InsertAsSnippet"}(r||(r={})),function(e){e[e.Method=0]="Method",e[e.Function=1]="Function",e[e.Constructor=2]="Constructor",e[e.Field=3]="Field",e[e.Variable=4]="Variable",e[e.Class=5]="Class",e[e.Struct=6]="Struct",e[e.Interface=7]="Interface",e[e.Module=8]="Module",e[e.Property=9]="Property",e[e.Event=10]="Event",e[e.Operator=11]="Operator",e[e.Unit=12]="Unit",e[e.Value=13]="Value",e[e.Constant=14]="Constant",e[e.Enum=15]="Enum",e[e.EnumMember=16]="EnumMember",e[e.Keyword=17]="Keyword",e[e.Text=18]="Text",e[e.Color=19]="Color",e[e.File=20]="File",e[e.Reference=21]="Reference",e[e.Customcolor=22]="Customcolor",e[e.Folder=23]="Folder",e[e.TypeParameter=24]="TypeParameter",e[e.User=25]="User",e[e.Issue=26]="Issue",e[e.Snippet=27]="Snippet"}(o||(o={})),function(e){e[e.Deprecated=1]="Deprecated"}(a||(a={})),function(e){e[e.Invoke=0]="Invoke",e[e.TriggerCharacter=1]="TriggerCharacter",e[e.TriggerForIncompleteCompletions=2]="TriggerForIncompleteCompletions"}(l||(l={})),function(e){e[e.EXACT=0]="EXACT",e[e.ABOVE=1]="ABOVE",e[e.BELOW=2]="BELOW"}(c||(c={})),function(e){e[e.NotSet=0]="NotSet",e[e.ContentFlush=1]="ContentFlush",e[e.RecoverFromMarkers=2]="RecoverFromMarkers",e[e.Explicit=3]="Explicit",e[e.Paste=4]="Paste",e[e.Undo=5]="Undo",e[e.Redo=6]="Redo"}(h||(h={})),function(e){e[e.LF=1]="LF",e[e.CRLF=2]="CRLF"}(d||(d={})),function(e){e[e.Text=0]="Text",e[e.Read=1]="Read",e[e.Write=2]="Write"}(u||(u={})),function(e){e[e.None=0]="None",e[e.Keep=1]="Keep",e[e.Brackets=2]="Brackets",e[e.Advanced=3]="Advanced",e[e.Full=4]="Full"}(g||(g={})),function(e){e[e.acceptSuggestionOnCommitCharacter=0]="acceptSuggestionOnCommitCharacter",e[e.acceptSuggestionOnEnter=1]="acceptSuggestionOnEnter",e[e.accessibilitySupport=2]="accessibilitySupport",e[e.accessibilityPageSize=3]="accessibilityPageSize",e[e.ariaLabel=4]="ariaLabel",e[e.ariaRequired=5]="ariaRequired",e[e.autoClosingBrackets=6]="autoClosingBrackets",e[e.autoClosingComments=7]="autoClosingComments",e[e.screenReaderAnnounceInlineSuggestion=8]="screenReaderAnnounceInlineSuggestion",e[e.autoClosingDelete=9]="autoClosingDelete",e[e.autoClosingOvertype=10]="autoClosingOvertype",e[e.autoClosingQuotes=11]="autoClosingQuotes",e[e.autoIndent=12]="autoIndent",e[e.automaticLayout=13]="automaticLayout",e[e.autoSurround=14]="autoSurround",e[e.bracketPairColorization=15]="bracketPairColorization",e[e.guides=16]="guides",e[e.codeLens=17]="codeLens",e[e.codeLensFontFamily=18]="codeLensFontFamily",e[e.codeLensFontSize=19]="codeLensFontSize",e[e.colorDecorators=20]="colorDecorators",e[e.colorDecoratorsLimit=21]="colorDecoratorsLimit",e[e.columnSelection=22]="columnSelection",e[e.comments=23]="comments",e[e.contextmenu=24]="contextmenu",e[e.copyWithSyntaxHighlighting=25]="copyWithSyntaxHighlighting",e[e.cursorBlinking=26]="cursorBlinking",e[e.cursorSmoothCaretAnimation=27]="cursorSmoothCaretAnimation",e[e.cursorStyle=28]="cursorStyle",e[e.cursorSurroundingLines=29]="cursorSurroundingLines",e[e.cursorSurroundingLinesStyle=30]="cursorSurroundingLinesStyle",e[e.cursorWidth=31]="cursorWidth",e[e.disableLayerHinting=32]="disableLayerHinting",e[e.disableMonospaceOptimizations=33]="disableMonospaceOptimizations",e[e.domReadOnly=34]="domReadOnly",e[e.dragAndDrop=35]="dragAndDrop",e[e.dropIntoEditor=36]="dropIntoEditor",e[e.emptySelectionClipboard=37]="emptySelectionClipboard",e[e.experimentalWhitespaceRendering=38]="experimentalWhitespaceRendering",e[e.extraEditorClassName=39]="extraEditorClassName",e[e.fastScrollSensitivity=40]="fastScrollSensitivity",e[e.find=41]="find",e[e.fixedOverflowWidgets=42]="fixedOverflowWidgets",e[e.folding=43]="folding",e[e.foldingStrategy=44]="foldingStrategy",e[e.foldingHighlight=45]="foldingHighlight",e[e.foldingImportsByDefault=46]="foldingImportsByDefault",e[e.foldingMaximumRegions=47]="foldingMaximumRegions",e[e.unfoldOnClickAfterEndOfLine=48]="unfoldOnClickAfterEndOfLine",e[e.fontFamily=49]="fontFamily",e[e.fontInfo=50]="fontInfo",e[e.fontLigatures=51]="fontLigatures",e[e.fontSize=52]="fontSize",e[e.fontWeight=53]="fontWeight",e[e.fontVariations=54]="fontVariations",e[e.formatOnPaste=55]="formatOnPaste",e[e.formatOnType=56]="formatOnType",e[e.glyphMargin=57]="glyphMargin",e[e.gotoLocation=58]="gotoLocation",e[e.hideCursorInOverviewRuler=59]="hideCursorInOverviewRuler",e[e.hover=60]="hover",e[e.inDiffEditor=61]="inDiffEditor",e[e.inlineSuggest=62]="inlineSuggest",e[e.inlineEdit=63]="inlineEdit",e[e.letterSpacing=64]="letterSpacing",e[e.lightbulb=65]="lightbulb",e[e.lineDecorationsWidth=66]="lineDecorationsWidth",e[e.lineHeight=67]="lineHeight",e[e.lineNumbers=68]="lineNumbers",e[e.lineNumbersMinChars=69]="lineNumbersMinChars",e[e.linkedEditing=70]="linkedEditing",e[e.links=71]="links",e[e.matchBrackets=72]="matchBrackets",e[e.minimap=73]="minimap",e[e.mouseStyle=74]="mouseStyle",e[e.mouseWheelScrollSensitivity=75]="mouseWheelScrollSensitivity",e[e.mouseWheelZoom=76]="mouseWheelZoom",e[e.multiCursorMergeOverlapping=77]="multiCursorMergeOverlapping",e[e.multiCursorModifier=78]="multiCursorModifier",e[e.multiCursorPaste=79]="multiCursorPaste",e[e.multiCursorLimit=80]="multiCursorLimit",e[e.occurrencesHighlight=81]="occurrencesHighlight",e[e.overviewRulerBorder=82]="overviewRulerBorder",e[e.overviewRulerLanes=83]="overviewRulerLanes",e[e.padding=84]="padding",e[e.pasteAs=85]="pasteAs",e[e.parameterHints=86]="parameterHints",e[e.peekWidgetDefaultFocus=87]="peekWidgetDefaultFocus",e[e.placeholder=88]="placeholder",e[e.definitionLinkOpensInPeek=89]="definitionLinkOpensInPeek",e[e.quickSuggestions=90]="quickSuggestions",e[e.quickSuggestionsDelay=91]="quickSuggestionsDelay",e[e.readOnly=92]="readOnly",e[e.readOnlyMessage=93]="readOnlyMessage",e[e.renameOnType=94]="renameOnType",e[e.renderControlCharacters=95]="renderControlCharacters",e[e.renderFinalNewline=96]="renderFinalNewline",e[e.renderLineHighlight=97]="renderLineHighlight",e[e.renderLineHighlightOnlyWhenFocus=98]="renderLineHighlightOnlyWhenFocus",e[e.renderValidationDecorations=99]="renderValidationDecorations",e[e.renderWhitespace=100]="renderWhitespace",e[e.revealHorizontalRightPadding=101]="revealHorizontalRightPadding",e[e.roundedSelection=102]="roundedSelection",e[e.rulers=103]="rulers",e[e.scrollbar=104]="scrollbar",e[e.scrollBeyondLastColumn=105]="scrollBeyondLastColumn",e[e.scrollBeyondLastLine=106]="scrollBeyondLastLine",e[e.scrollPredominantAxis=107]="scrollPredominantAxis",e[e.selectionClipboard=108]="selectionClipboard",e[e.selectionHighlight=109]="selectionHighlight",e[e.selectOnLineNumbers=110]="selectOnLineNumbers",e[e.showFoldingControls=111]="showFoldingControls",e[e.showUnused=112]="showUnused",e[e.snippetSuggestions=113]="snippetSuggestions",e[e.smartSelect=114]="smartSelect",e[e.smoothScrolling=115]="smoothScrolling",e[e.stickyScroll=116]="stickyScroll",e[e.stickyTabStops=117]="stickyTabStops",e[e.stopRenderingLineAfter=118]="stopRenderingLineAfter",e[e.suggest=119]="suggest",e[e.suggestFontSize=120]="suggestFontSize",e[e.suggestLineHeight=121]="suggestLineHeight",e[e.suggestOnTriggerCharacters=122]="suggestOnTriggerCharacters",e[e.suggestSelection=123]="suggestSelection",e[e.tabCompletion=124]="tabCompletion",e[e.tabIndex=125]="tabIndex",e[e.unicodeHighlighting=126]="unicodeHighlighting",e[e.unusualLineTerminators=127]="unusualLineTerminators",e[e.useShadowDOM=128]="useShadowDOM",e[e.useTabStops=129]="useTabStops",e[e.wordBreak=130]="wordBreak",e[e.wordSegmenterLocales=131]="wordSegmenterLocales",e[e.wordSeparators=132]="wordSeparators",e[e.wordWrap=133]="wordWrap",e[e.wordWrapBreakAfterCharacters=134]="wordWrapBreakAfterCharacters",e[e.wordWrapBreakBeforeCharacters=135]="wordWrapBreakBeforeCharacters",e[e.wordWrapColumn=136]="wordWrapColumn",e[e.wordWrapOverride1=137]="wordWrapOverride1",e[e.wordWrapOverride2=138]="wordWrapOverride2",e[e.wrappingIndent=139]="wrappingIndent",e[e.wrappingStrategy=140]="wrappingStrategy",e[e.showDeprecated=141]="showDeprecated",e[e.inlayHints=142]="inlayHints",e[e.editorClassName=143]="editorClassName",e[e.pixelRatio=144]="pixelRatio",e[e.tabFocusMode=145]="tabFocusMode",e[e.layoutInfo=146]="layoutInfo",e[e.wrappingInfo=147]="wrappingInfo",e[e.defaultColorDecorators=148]="defaultColorDecorators",e[e.colorDecoratorsActivatedOn=149]="colorDecoratorsActivatedOn",e[e.inlineCompletionsAccessibilityVerbose=150]="inlineCompletionsAccessibilityVerbose"}(p||(p={})),function(e){e[e.TextDefined=0]="TextDefined",e[e.LF=1]="LF",e[e.CRLF=2]="CRLF"}(m||(m={})),function(e){e[e.LF=0]="LF",e[e.CRLF=1]="CRLF"}(f||(f={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=3]="Right"}(_||(_={})),function(e){e[e.Increase=0]="Increase",e[e.Decrease=1]="Decrease"}(v||(v={})),function(e){e[e.None=0]="None",e[e.Indent=1]="Indent",e[e.IndentOutdent=2]="IndentOutdent",e[e.Outdent=3]="Outdent"}(C||(C={})),function(e){e[e.Both=0]="Both",e[e.Right=1]="Right",e[e.Left=2]="Left",e[e.None=3]="None"}(b||(b={})),function(e){e[e.Type=1]="Type",e[e.Parameter=2]="Parameter"}(E||(E={})),function(e){e[e.Automatic=0]="Automatic",e[e.Explicit=1]="Explicit"}(S||(S={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(y||(y={})),function(e){e[e.DependsOnKbLayout=-1]="DependsOnKbLayout",e[e.Unknown=0]="Unknown",e[e.Backspace=1]="Backspace",e[e.Tab=2]="Tab",e[e.Enter=3]="Enter",e[e.Shift=4]="Shift",e[e.Ctrl=5]="Ctrl",e[e.Alt=6]="Alt",e[e.PauseBreak=7]="PauseBreak",e[e.CapsLock=8]="CapsLock",e[e.Escape=9]="Escape",e[e.Space=10]="Space",e[e.PageUp=11]="PageUp",e[e.PageDown=12]="PageDown",e[e.End=13]="End",e[e.Home=14]="Home",e[e.LeftArrow=15]="LeftArrow",e[e.UpArrow=16]="UpArrow",e[e.RightArrow=17]="RightArrow",e[e.DownArrow=18]="DownArrow",e[e.Insert=19]="Insert",e[e.Delete=20]="Delete",e[e.Digit0=21]="Digit0",e[e.Digit1=22]="Digit1",e[e.Digit2=23]="Digit2",e[e.Digit3=24]="Digit3",e[e.Digit4=25]="Digit4",e[e.Digit5=26]="Digit5",e[e.Digit6=27]="Digit6",e[e.Digit7=28]="Digit7",e[e.Digit8=29]="Digit8",e[e.Digit9=30]="Digit9",e[e.KeyA=31]="KeyA",e[e.KeyB=32]="KeyB",e[e.KeyC=33]="KeyC",e[e.KeyD=34]="KeyD",e[e.KeyE=35]="KeyE",e[e.KeyF=36]="KeyF",e[e.KeyG=37]="KeyG",e[e.KeyH=38]="KeyH",e[e.KeyI=39]="KeyI",e[e.KeyJ=40]="KeyJ",e[e.KeyK=41]="KeyK",e[e.KeyL=42]="KeyL",e[e.KeyM=43]="KeyM",e[e.KeyN=44]="KeyN",e[e.KeyO=45]="KeyO",e[e.KeyP=46]="KeyP",e[e.KeyQ=47]="KeyQ",e[e.KeyR=48]="KeyR",e[e.KeyS=49]="KeyS",e[e.KeyT=50]="KeyT",e[e.KeyU=51]="KeyU",e[e.KeyV=52]="KeyV",e[e.KeyW=53]="KeyW",e[e.KeyX=54]="KeyX",e[e.KeyY=55]="KeyY",e[e.KeyZ=56]="KeyZ",e[e.Meta=57]="Meta",e[e.ContextMenu=58]="ContextMenu",e[e.F1=59]="F1",e[e.F2=60]="F2",e[e.F3=61]="F3",e[e.F4=62]="F4",e[e.F5=63]="F5",e[e.F6=64]="F6",e[e.F7=65]="F7",e[e.F8=66]="F8",e[e.F9=67]="F9",e[e.F10=68]="F10",e[e.F11=69]="F11",e[e.F12=70]="F12",e[e.F13=71]="F13",e[e.F14=72]="F14",e[e.F15=73]="F15",e[e.F16=74]="F16",e[e.F17=75]="F17",e[e.F18=76]="F18",e[e.F19=77]="F19",e[e.F20=78]="F20",e[e.F21=79]="F21",e[e.F22=80]="F22",e[e.F23=81]="F23",e[e.F24=82]="F24",e[e.NumLock=83]="NumLock",e[e.ScrollLock=84]="ScrollLock",e[e.Semicolon=85]="Semicolon",e[e.Equal=86]="Equal",e[e.Comma=87]="Comma",e[e.Minus=88]="Minus",e[e.Period=89]="Period",e[e.Slash=90]="Slash",e[e.Backquote=91]="Backquote",e[e.BracketLeft=92]="BracketLeft",e[e.Backslash=93]="Backslash",e[e.BracketRight=94]="BracketRight",e[e.Quote=95]="Quote",e[e.OEM_8=96]="OEM_8",e[e.IntlBackslash=97]="IntlBackslash",e[e.Numpad0=98]="Numpad0",e[e.Numpad1=99]="Numpad1",e[e.Numpad2=100]="Numpad2",e[e.Numpad3=101]="Numpad3",e[e.Numpad4=102]="Numpad4",e[e.Numpad5=103]="Numpad5",e[e.Numpad6=104]="Numpad6",e[e.Numpad7=105]="Numpad7",e[e.Numpad8=106]="Numpad8",e[e.Numpad9=107]="Numpad9",e[e.NumpadMultiply=108]="NumpadMultiply",e[e.NumpadAdd=109]="NumpadAdd",e[e.NUMPAD_SEPARATOR=110]="NUMPAD_SEPARATOR",e[e.NumpadSubtract=111]="NumpadSubtract",e[e.NumpadDecimal=112]="NumpadDecimal",e[e.NumpadDivide=113]="NumpadDivide",e[e.KEY_IN_COMPOSITION=114]="KEY_IN_COMPOSITION",e[e.ABNT_C1=115]="ABNT_C1",e[e.ABNT_C2=116]="ABNT_C2",e[e.AudioVolumeMute=117]="AudioVolumeMute",e[e.AudioVolumeUp=118]="AudioVolumeUp",e[e.AudioVolumeDown=119]="AudioVolumeDown",e[e.BrowserSearch=120]="BrowserSearch",e[e.BrowserHome=121]="BrowserHome",e[e.BrowserBack=122]="BrowserBack",e[e.BrowserForward=123]="BrowserForward",e[e.MediaTrackNext=124]="MediaTrackNext",e[e.MediaTrackPrevious=125]="MediaTrackPrevious",e[e.MediaStop=126]="MediaStop",e[e.MediaPlayPause=127]="MediaPlayPause",e[e.LaunchMediaPlayer=128]="LaunchMediaPlayer",e[e.LaunchMail=129]="LaunchMail",e[e.LaunchApp2=130]="LaunchApp2",e[e.Clear=131]="Clear",e[e.MAX_VALUE=132]="MAX_VALUE"}(w||(w={})),function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(L||(L={})),function(e){e[e.Unnecessary=1]="Unnecessary",e[e.Deprecated=2]="Deprecated"}(R||(R={})),function(e){e[e.Inline=1]="Inline",e[e.Gutter=2]="Gutter"}(T||(T={})),function(e){e[e.Normal=1]="Normal",e[e.Underlined=2]="Underlined"}(x||(x={})),function(e){e[e.UNKNOWN=0]="UNKNOWN",e[e.TEXTAREA=1]="TEXTAREA",e[e.GUTTER_GLYPH_MARGIN=2]="GUTTER_GLYPH_MARGIN",e[e.GUTTER_LINE_NUMBERS=3]="GUTTER_LINE_NUMBERS",e[e.GUTTER_LINE_DECORATIONS=4]="GUTTER_LINE_DECORATIONS",e[e.GUTTER_VIEW_ZONE=5]="GUTTER_VIEW_ZONE",e[e.CONTENT_TEXT=6]="CONTENT_TEXT",e[e.CONTENT_EMPTY=7]="CONTENT_EMPTY",e[e.CONTENT_VIEW_ZONE=8]="CONTENT_VIEW_ZONE",e[e.CONTENT_WIDGET=9]="CONTENT_WIDGET",e[e.OVERVIEW_RULER=10]="OVERVIEW_RULER",e[e.SCROLLBAR=11]="SCROLLBAR",e[e.OVERLAY_WIDGET=12]="OVERLAY_WIDGET",e[e.OUTSIDE_EDITOR=13]="OUTSIDE_EDITOR"}(k||(k={})),function(e){e[e.AIGenerated=1]="AIGenerated"}(A||(A={})),function(e){e[e.Invoke=0]="Invoke",e[e.Automatic=1]="Automatic"}(N||(N={})),function(e){e[e.TOP_RIGHT_CORNER=0]="TOP_RIGHT_CORNER",e[e.BOTTOM_RIGHT_CORNER=1]="BOTTOM_RIGHT_CORNER",e[e.TOP_CENTER=2]="TOP_CENTER"}(I||(I={})),function(e){e[e.Left=1]="Left",e[e.Center=2]="Center",e[e.Right=4]="Right",e[e.Full=7]="Full"}(O||(O={})),function(e){e[e.Word=0]="Word",e[e.Line=1]="Line",e[e.Suggest=2]="Suggest"}(D||(D={})),function(e){e[e.Left=0]="Left",e[e.Right=1]="Right",e[e.None=2]="None",e[e.LeftOfInjectedText=3]="LeftOfInjectedText",e[e.RightOfInjectedText=4]="RightOfInjectedText"}(M||(M={})),function(e){e[e.Off=0]="Off",e[e.On=1]="On",e[e.Relative=2]="Relative",e[e.Interval=3]="Interval",e[e.Custom=4]="Custom"}(P||(P={})),function(e){e[e.None=0]="None",e[e.Text=1]="Text",e[e.Blocks=2]="Blocks"}(F||(F={})),function(e){e[e.Smooth=0]="Smooth",e[e.Immediate=1]="Immediate"}(U||(U={})),function(e){e[e.Auto=1]="Auto",e[e.Hidden=2]="Hidden",e[e.Visible=3]="Visible"}(H||(H={})),function(e){e[e.LTR=0]="LTR",e[e.RTL=1]="RTL"}(B||(B={})),function(e){e.Off="off",e.OnCode="onCode",e.On="on"}(W||(W={})),function(e){e[e.Invoke=1]="Invoke",e[e.TriggerCharacter=2]="TriggerCharacter",e[e.ContentChange=3]="ContentChange"}(V||(V={})),function(e){e[e.File=0]="File",e[e.Module=1]="Module",e[e.Namespace=2]="Namespace",e[e.Package=3]="Package",e[e.Class=4]="Class",e[e.Method=5]="Method",e[e.Property=6]="Property",e[e.Field=7]="Field",e[e.Constructor=8]="Constructor",e[e.Enum=9]="Enum",e[e.Interface=10]="Interface",e[e.Function=11]="Function",e[e.Variable=12]="Variable",e[e.Constant=13]="Constant",e[e.String=14]="String",e[e.Number=15]="Number",e[e.Boolean=16]="Boolean",e[e.Array=17]="Array",e[e.Object=18]="Object",e[e.Key=19]="Key",e[e.Null=20]="Null",e[e.EnumMember=21]="EnumMember",e[e.Struct=22]="Struct",e[e.Event=23]="Event",e[e.Operator=24]="Operator",e[e.TypeParameter=25]="TypeParameter"}(z||(z={})),function(e){e[e.Deprecated=1]="Deprecated"}(G||(G={})),function(e){e[e.Hidden=0]="Hidden",e[e.Blink=1]="Blink",e[e.Smooth=2]="Smooth",e[e.Phase=3]="Phase",e[e.Expand=4]="Expand",e[e.Solid=5]="Solid"}(j||(j={})),function(e){e[e.Line=1]="Line",e[e.Block=2]="Block",e[e.Underline=3]="Underline",e[e.LineThin=4]="LineThin",e[e.BlockOutline=5]="BlockOutline",e[e.UnderlineThin=6]="UnderlineThin"}(K||(K={})),function(e){e[e.AlwaysGrowsWhenTypingAtEdges=0]="AlwaysGrowsWhenTypingAtEdges",e[e.NeverGrowsWhenTypingAtEdges=1]="NeverGrowsWhenTypingAtEdges",e[e.GrowsOnlyWhenTypingBefore=2]="GrowsOnlyWhenTypingBefore",e[e.GrowsOnlyWhenTypingAfter=3]="GrowsOnlyWhenTypingAfter"}(Y||(Y={})),function(e){e[e.None=0]="None",e[e.Same=1]="Same",e[e.Indent=2]="Indent",e[e.DeepIndent=3]="DeepIndent"}(q||(q={}))},51861:(e,t,i)=>{"use strict";i.d(t,{E6:()=>c,Hw:()=>n,YN:()=>s,gf:()=>o,n9:()=>a,oq:()=>r,tu:()=>h,vp:()=>l});var s,n,r,o,a,l,c,h,d=i(78209);!function(e){e.inspectTokensAction=d.kg("inspectTokens","Developer: Inspect Tokens")}(s||(s={})),function(e){e.gotoLineActionLabel=d.kg("gotoLineActionLabel","Go to Line/Column...")}(n||(n={})),function(e){e.helpQuickAccessActionLabel=d.kg("helpQuickAccess","Show all Quick Access Providers")}(r||(r={})),function(e){e.quickCommandActionLabel=d.kg("quickCommandActionLabel","Command Palette"),e.quickCommandHelp=d.kg("quickCommandActionHelp","Show And Run Commands")}(o||(o={})),function(e){e.quickOutlineActionLabel=d.kg("quickOutlineActionLabel","Go to Symbol..."),e.quickOutlineByCategoryActionLabel=d.kg("quickOutlineByCategoryActionLabel","Go to Symbol by Category...")}(a||(a={})),function(e){e.editorViewAccessibleLabel=d.kg("editorViewAccessibleLabel","Editor content")}(l||(l={})),function(e){e.toggleHighContrast=d.kg("toggleHighContrast","Toggle High Contrast Theme")}(c||(c={})),function(e){e.bulkEditServiceSummary=d.kg("bulkEditServiceSummary","Made {0} edits in {1} files")}(h||(h={}))},64727:(e,t,i)=>{"use strict";i.d(t,{E$:()=>o,HP:()=>c,Ic:()=>d,U0:()=>r,Wn:()=>s,bg:()=>a,mS:()=>l,uK:()=>n,vn:()=>h});class s{constructor(){this.changeType=1}}class n{static applyInjectedText(e,t){if(!t||0===t.length)return e;let i="",s=0;for(const n of t)i+=e.substring(s,n.column-1),s=n.column-1,i+=n.options.content;return i+=e.substring(s),i}static fromDecorations(e){const t=[];for(const i of e)i.options.before&&i.options.before.content.length>0&&t.push(new n(i.ownerId,i.range.startLineNumber,i.range.startColumn,i.options.before,0)),i.options.after&&i.options.after.content.length>0&&t.push(new n(i.ownerId,i.range.endLineNumber,i.range.endColumn,i.options.after,1));return t.sort(((e,t)=>e.lineNumber===t.lineNumber?e.column===t.column?e.order-t.order:e.column-t.column:e.lineNumber-t.lineNumber)),t}constructor(e,t,i,s,n){this.ownerId=e,this.lineNumber=t,this.column=i,this.options=s,this.order=n}}class r{constructor(e,t,i){this.changeType=2,this.lineNumber=e,this.detail=t,this.injectedText=i}}class o{constructor(e,t){this.changeType=3,this.fromLineNumber=e,this.toLineNumber=t}}class a{constructor(e,t,i,s){this.changeType=4,this.injectedTexts=s,this.fromLineNumber=e,this.toLineNumber=t,this.detail=i}}class l{constructor(){this.changeType=5}}class c{constructor(e,t,i,s){this.changes=e,this.versionId=t,this.isUndoing=i,this.isRedoing=s,this.resultingSelection=null}containsEvent(e){for(let t=0,i=this.changes.length;t{"use strict";var s;i.d(t,{N6:()=>s,TH:()=>n,pv:()=>r}),function(e){e[e.Disabled=0]="Disabled",e[e.EnabledForActive=1]="EnabledForActive",e[e.Enabled=2]="Enabled"}(s||(s={}));class n{constructor(e,t,i,s,n,r){if(this.visibleColumn=e,this.column=t,this.className=i,this.horizontalLine=s,this.forWrappedLinesAfterColumn=n,this.forWrappedLinesBeforeOrAtColumn=r,-1!==e===(-1!==t))throw new Error}}class r{constructor(e,t){this.top=e,this.endColumn=t}}},87469:(e,t,i)=>{"use strict";i.d(t,{T:()=>o,f:()=>n});var s=i(25982);class n{static{this.defaultTokenMetadata=33587200}static createEmpty(e,t){const i=n.defaultTokenMetadata,s=new Uint32Array(2);return s[0]=e.length,s[1]=i,new n(s,e,t)}static createFromTextAndMetadata(e,t){let i=0,s="";const r=new Array;for(const{text:n,metadata:o}of e)r.push(i+n.length,o),i+=n.length,s+=n;return new n(new Uint32Array(r),s,t)}constructor(e,t,i){this._lineTokensBrand=void 0,this._tokens=e,this._tokensCount=this._tokens.length>>>1,this._text=t,this.languageIdCodec=i}equals(e){return e instanceof n&&this.slicedEquals(e,0,this._tokensCount)}slicedEquals(e,t,i){if(this._text!==e._text)return!1;if(this._tokensCount!==e._tokensCount)return!1;const s=t<<1,n=s+(i<<1);for(let r=s;r0?this._tokens[e-1<<1]:0}getMetadata(e){return this._tokens[1+(e<<1)]}getLanguageId(e){const t=this._tokens[1+(e<<1)],i=s.x.getLanguageId(t);return this.languageIdCodec.decodeLanguageId(i)}getStandardTokenType(e){const t=this._tokens[1+(e<<1)];return s.x.getTokenType(t)}getForeground(e){const t=this._tokens[1+(e<<1)];return s.x.getForeground(t)}getClassName(e){const t=this._tokens[1+(e<<1)];return s.x.getClassNameFromMetadata(t)}getInlineStyle(e,t){const i=this._tokens[1+(e<<1)];return s.x.getInlineStyleFromMetadata(i,t)}getPresentation(e){const t=this._tokens[1+(e<<1)];return s.x.getPresentationFromMetadata(t)}getEndOffset(e){return this._tokens[e<<1]}findTokenIndexAtOffset(e){return n.findIndexInTokensArray(this._tokens,e)}inflate(){return this}sliceAndInflate(e,t,i){return new r(this,e,t,i)}static convertToEndOffset(e,t){const i=(e.length>>>1)-1;for(let s=0;s>>1)-1;for(;it&&(s=n)}return i}withInserted(e){if(0===e.length)return this;let t=0,i=0,s="";const r=new Array;let o=0;for(;;){const n=to){s+=this._text.substring(o,a.offset);const e=this._tokens[1+(t<<1)];r.push(s.length,e),o=a.offset}s+=a.text,r.push(s.length,a.tokenMetadata),i++}}return new n(new Uint32Array(r),s,this.languageIdCodec)}getTokenText(e){const t=this.getStartOffset(e),i=this.getEndOffset(e);return this._text.substring(t,i)}forEach(e){const t=this.getCount();for(let i=0;i=i)break;this._tokensCount++}}getMetadata(e){return this._source.getMetadata(this._firstTokenIndex+e)}getLanguageId(e){return this._source.getLanguageId(this._firstTokenIndex+e)}getLineContent(){return this._source.getLineContent().substring(this._startOffset,this._endOffset)}equals(e){return e instanceof r&&(this._startOffset===e._startOffset&&this._endOffset===e._endOffset&&this._deltaOffset===e._deltaOffset&&this._source.slicedEquals(e._source,this._firstTokenIndex,this._tokensCount))}getCount(){return this._tokensCount}getStandardTokenType(e){return this._source.getStandardTokenType(this._firstTokenIndex+e)}getForeground(e){return this._source.getForeground(this._firstTokenIndex+e)}getEndOffset(e){const t=this._source.getEndOffset(this._firstTokenIndex+e);return Math.min(this._endOffset,t)-this._startOffset+this._deltaOffset}getClassName(e){return this._source.getClassName(this._firstTokenIndex+e)}getInlineStyle(e,t){return this._source.getInlineStyle(this._firstTokenIndex+e,t)}getPresentation(e){return this._source.getPresentation(this._firstTokenIndex+e)}findTokenIndexAtOffset(e){return this._source.findTokenIndexAtOffset(e+this._startOffset-this._deltaOffset)-this._firstTokenIndex}getTokenText(e){const t=this._firstTokenIndex+e,i=this._source.getStartOffset(t),s=this._source.getEndOffset(t);let n=this._source.getTokenText(t);return ithis._endOffset&&(n=n.substring(0,n.length-(s-this._endOffset))),n}forEach(e){for(let t=0;t{"use strict";i.d(t,{Bs:()=>a,d:()=>n});var s=i(91508);class n{constructor(e,t,i,s){this.startColumn=e,this.endColumn=t,this.className=i,this.type=s,this._lineDecorationBrand=void 0}static _equals(e,t){return e.startColumn===t.startColumn&&e.endColumn===t.endColumn&&e.className===t.className&&e.type===t.type}static equalsArr(e,t){const i=e.length;if(i!==t.length)return!1;for(let s=0;s=r||(a[l++]=new n(Math.max(1,c.startColumn-s+1),Math.min(o+1,c.endColumn-s+1),c.className,c.type));return a}static filter(e,t,i,s){if(0===e.length)return[];const r=[];let o=0;for(let a=0,l=e.length;at)continue;if(c.isEmpty()&&(0===l.type||3===l.type))continue;const h=c.startLineNumber===t?c.startColumn:i,d=c.endLineNumber===t?c.endColumn:s;r[o++]=new n(h,d,l.inlineClassName,l.type)}return r}static _typeCompare(e,t){const i=[2,0,1,3];return i[e]-i[t]}static compare(e,t){if(e.startColumn!==t.startColumn)return e.startColumn-t.startColumn;if(e.endColumn!==t.endColumn)return e.endColumn-t.endColumn;const i=n._typeCompare(e.type,t.type);return 0!==i?i:e.className!==t.className?e.className0&&this.stopOffsets[0]0&&t=e){this.stopOffsets.splice(s,0,e),this.classNames.splice(s,0,t),this.metadata.splice(s,0,i);break}this.count++}}class a{static normalize(e,t){if(0===t.length)return[];const i=[],n=new o;let r=0;for(let o=0,a=t.length;o1){const t=e.charCodeAt(l-2);s.pc(t)&&l--}if(c>1){const t=e.charCodeAt(c-2);s.pc(t)&&c--}const u=l-1,g=c-2;r=n.consumeLowerThan(u,r,i),0===n.count&&(r=u),n.insert(g,h,d)}return n.consumeLowerThan(1073741824,r,i),i}}},35600:(e,t,i)=>{"use strict";i.d(t,{wZ:()=>h,MT:()=>l,zL:()=>c,UW:()=>g,Md:()=>m});var s=i(78209),n=i(91508),r=i(99020),o=i(25521);class a{constructor(e,t,i,s){this.endIndex=e,this.type=t,this.metadata=i,this.containsRTL=s,this._linePartBrand=void 0}isWhitespace(){return!!(1&this.metadata)}isPseudoAfter(){return!!(4&this.metadata)}}class l{constructor(e,t){this.startOffset=e,this.endOffset=t}equals(e){return this.startOffset===e.startOffset&&this.endOffset===e.endOffset}}class c{constructor(e,t,i,s,n,r,a,l,c,h,d,u,g,p,m,f,_,v,C){this.useMonospaceOptimizations=e,this.canUseHalfwidthRightwardsArrow=t,this.lineContent=i,this.continuesWithWrappedLine=s,this.isBasicASCII=n,this.containsRTL=r,this.fauxIndentLength=a,this.lineTokens=l,this.lineDecorations=c.sort(o.d.compare),this.tabSize=h,this.startVisibleColumn=d,this.spaceWidth=u,this.stopRenderingLineAfter=m,this.renderWhitespace="all"===f?4:"boundary"===f?1:"selection"===f?2:"trailing"===f?3:0,this.renderControlCharacters=_,this.fontLigatures=v,this.selectionsOnLine=C&&C.sort(((e,t)=>e.startOffset>>16}static getCharIndex(e){return(65535&e)>>>0}constructor(e,t){this.length=e,this._data=new Uint32Array(this.length),this._horizontalOffset=new Uint32Array(this.length)}setColumnInfo(e,t,i,s){const n=(t<<16|i)>>>0;this._data[e-1]=n,this._horizontalOffset[e-1]=s}getHorizontalOffset(e){return 0===this._horizontalOffset.length?0:this._horizontalOffset[e-1]}charOffsetToPartData(e){return 0===this.length?0:e<0?this._data[0]:e>=this.length?this._data[this.length-1]:this._data[e]}getDomPosition(e){const t=this.charOffsetToPartData(e-1),i=d.getPartIndex(t),s=d.getCharIndex(t);return new h(i,s)}getColumn(e,t){return this.partDataToCharOffset(e.partIndex,t,e.charIndex)+1}partDataToCharOffset(e,t,i){if(0===this.length)return 0;const s=(e<<16|i)>>>0;let n=0,r=this.length-1;for(;n+1>>1,t=this._data[e];if(t===s)return e;t>s?r=e:n=e}if(n===r)return n;const o=this._data[n],a=this._data[r];if(o===s)return n;if(a===s)return r;const l=d.getPartIndex(o),c=d.getCharIndex(o);let h;h=l!==d.getPartIndex(a)?t:d.getCharIndex(a);return i-c<=h-i?n:r}}class u{constructor(e,t,i){this._renderLineOutputBrand=void 0,this.characterMapping=e,this.containsRTL=t,this.containsForeignElements=i}}function g(e,t){if(0===e.lineContent.length){if(e.lineDecorations.length>0){t.appendString("");let i=0,s=0,n=0;for(const o of e.lineDecorations)1!==o.type&&2!==o.type||(t.appendString(''),1===o.type&&(n|=1,i++),2===o.type&&(n|=2,s++));t.appendString("");const r=new d(1,i+s);return r.setColumnInfo(1,i,0,0),new u(r,!1,n)}return t.appendString(""),new u(new d(0,0),!1,0)}return function(e,t){const i=e.fontIsMonospace,r=e.canUseHalfwidthRightwardsArrow,o=e.containsForeignElements,a=e.lineContent,l=e.len,c=e.isOverflowing,h=e.overflowingCharCount,g=e.parts,p=e.fauxIndentLength,m=e.tabSize,f=e.startVisibleColumn,C=e.containsRTL,b=e.spaceWidth,E=e.renderSpaceCharCode,S=e.renderWhitespace,y=e.renderControlCharacters,w=new d(l+1,g.length);let L=!1,R=0,T=f,x=0,k=0,A=0;C?t.appendString(''):t.appendString("");for(let s=0,d=g.length;s=p&&(i+=s)}}for(f&&(t.appendString(' style="width:'),t.appendString(String(b*e)),t.appendString('px"')),t.appendASCIICharCode(62);R1?t.appendCharCode(8594):t.appendCharCode(65515);for(let e=2;e<=i;e++)t.appendCharCode(160)}else e=2,i=1,t.appendCharCode(E),t.appendCharCode(8204);x+=e,k+=i,R>=p&&(T+=i)}}else for(t.appendASCIICharCode(62);R=p&&(T+=r)}C?A++:A=0,R>=l&&!L&&e.isPseudoAfter()&&(L=!0,w.setColumnInfo(R+1,s,x,k)),t.appendString("")}L||w.setColumnInfo(l+1,g.length-1,x,k);c&&(t.appendString(''),t.appendString(s.kg("showMore","Show more ({0})",function(e){if(e<1024)return s.kg("overflow.chars","{0} chars",e);if(e<1048576)return`${(e/1024).toFixed(1)} KB`;return`${(e/1024/1024).toFixed(1)} MB`}(h))),t.appendString(""));return t.appendString(""),new u(w,C,o)}(function(e){const t=e.lineContent;let i,s,r;-1!==e.stopRenderingLineAfter&&e.stopRenderingLineAfter0&&(o[l++]=new a(s,"",0,!1));let c=s;for(let h=0,d=i.getCount();h=r){const i=!!t&&n.E_(e.substring(c,r));o[l++]=new a(r,u,0,i);break}const g=!!t&&n.E_(e.substring(c,d));o[l++]=new a(d,u,0,g),c=d}return o}(t,e.containsRTL,e.lineTokens,e.fauxIndentLength,r);e.renderControlCharacters&&!e.isBasicASCII&&(l=function(e,t){const i=[];let s=new a(0,"",0,!1),n=0;for(const r of t){const t=r.endIndex;for(;ns.endIndex&&(s=new a(n,r.type,r.metadata,r.containsRTL),i.push(s)),s=new a(n+1,"mtkcontrol",r.metadata,!1),i.push(s))}n>s.endIndex&&(s=new a(t,r.type,r.metadata,r.containsRTL),i.push(s))}return i}(t,l));(4===e.renderWhitespace||1===e.renderWhitespace||2===e.renderWhitespace&&e.selectionsOnLine||3===e.renderWhitespace&&!e.continuesWithWrappedLine)&&(l=function(e,t,i,s){const r=e.continuesWithWrappedLine,o=e.fauxIndentLength,l=e.tabSize,c=e.startVisibleColumn,h=e.useMonospaceOptimizations,d=e.selectionsOnLine,u=1===e.renderWhitespace,g=3===e.renderWhitespace,p=e.renderSpaceWidth!==e.spaceWidth,m=[];let f=0,_=0,v=s[_].type,C=s[_].containsRTL,b=s[_].endIndex;const E=s.length;let S,y=!1,w=n.HG(t);-1===w?(y=!0,w=i,S=i):S=n.lT(t);let L=!1,R=0,T=d&&d[R],x=c%l;for(let A=o;A=T.endOffset&&(R++,T=d&&d[R]),AS)r=!0;else if(9===e)r=!0;else if(32===e)if(u)if(L)r=!0;else{const e=A+1A),r&&g&&(r=y||A>S),r&&C&&A>=w&&A<=S&&(r=!1),L){if(!r||!h&&x>=l){if(p){for(let e=(f>0?m[f-1].endIndex:o)+1;e<=A;e++)m[f++]=new a(e,"mtkw",1,!1)}else m[f++]=new a(A,"mtkw",1,!1);x%=l}}else(A===b||r&&A>o)&&(m[f++]=new a(A,v,0,C),x%=l);for(9===e?x=l:n.ne(e)?x+=2:x++,L=r;A===b&&(_++,_0?t.charCodeAt(i-1):0,s=i>1?t.charCodeAt(i-2):0;32===e&&32!==s&&9!==s||(k=!0)}else k=!0;if(k)if(p){for(let e=(f>0?m[f-1].endIndex:o)+1;e<=i;e++)m[f++]=new a(e,"mtkw",1,!1)}else m[f++]=new a(i,"mtkw",1,!1);else m[f++]=new a(i,v,0,C);return m}(e,t,r,l));let c=0;if(e.lineDecorations.length>0){for(let t=0,i=e.lineDecorations.length;td&&(d=e.startOffset,c[h++]=new a(d,s,u,g)),!(e.endOffset+1<=t)){d=t,c[h++]=new a(d,s+" "+e.className,u|e.metadata,g);break}d=e.endOffset+1,c[h++]=new a(d,s+" "+e.className,u|e.metadata,g),l++}t>d&&(d=t,c[h++]=new a(d,s,u,g))}const u=i[i.length-1].endIndex;if(l=50&&(n[r++]=new a(h+1,t,o,c),d=h+1,h=-1);d!==l&&(n[r++]=new a(l,t,o,c))}else n[r++]=i;s=l}else for(let o=0,l=t.length;o50){const t=e.type,o=e.metadata,c=e.containsRTL,h=Math.ceil(l/50);for(let e=1;e=8234&&e<=8238||e>=8294&&e<=8297||e>=8206&&e<=8207||1564===e)}function v(e){return e.toString(16).toUpperCase().padStart(4,"0")}},92896:(e,t,i)=>{"use strict";i.d(t,{GP:()=>l,LM:()=>o,Uv:()=>g,kI:()=>h,nt:()=>a,or:()=>d,qL:()=>c,vo:()=>u});var s=i(25890),n=i(91508),r=i(36677);class o{constructor(e,t,i,s){this._viewportBrand=void 0,this.top=0|e,this.left=0|t,this.width=0|i,this.height=0|s}}class a{constructor(e,t){this.tabSize=e,this.data=t}}class l{constructor(e,t,i,s,n,r,o){this._viewLineDataBrand=void 0,this.content=e,this.continuesWithWrappedLine=t,this.minColumn=i,this.maxColumn=s,this.startVisibleColumn=n,this.tokens=r,this.inlineDecorations=o}}class c{constructor(e,t,i,s,n,r,o,a,l,h){this.minColumn=e,this.maxColumn=t,this.content=i,this.continuesWithWrappedLine=s,this.isBasicASCII=c.isBasicASCII(i,r),this.containsRTL=c.containsRTL(i,this.isBasicASCII,n),this.tokens=o,this.inlineDecorations=a,this.tabSize=l,this.startVisibleColumn=h}static isBasicASCII(e,t){return!t||n.aC(e)}static containsRTL(e,t,i){return!(t||!i)&&n.E_(e)}}class h{constructor(e,t,i){this.range=e,this.inlineClassName=t,this.type=i}}class d{constructor(e,t,i,s){this.startOffset=e,this.endOffset=t,this.inlineClassName=i,this.inlineClassNameAffectsLetterSpacing=s}toInlineDecoration(e){return new h(new r.Q(e,this.startOffset+1,e,this.endOffset+1),this.inlineClassName,this.inlineClassNameAffectsLetterSpacing?3:0)}}class u{constructor(e,t){this._viewModelDecorationBrand=void 0,this.range=e,this.options=t}}class g{constructor(e,t,i){this.color=e,this.zIndex=t,this.data=i}static compareByRenderingProps(e,t){return e.zIndex===t.zIndex?e.colort.color?1:0:e.zIndex-t.zIndex}static equals(e,t){return e.color===t.color&&e.zIndex===t.zIndex&&s.aI(e.data,t.data)}static equalsArr(e,t){return s.aI(e,t,g.equals)}}},19531:(e,t,i)=>{"use strict";i.d(t,{iE:()=>n,rW:()=>r});class s{constructor(e,t,i){this._colorZoneBrand=void 0,this.from=0|e,this.to=0|t,this.colorId=0|i}static compare(e,t){return e.colorId===t.colorId?e.from===t.from?e.to-t.to:e.from-t.from:e.colorId-t.colorId}}class n{constructor(e,t,i,s){this._overviewRulerZoneBrand=void 0,this.startLineNumber=e,this.endLineNumber=t,this.heightInLines=i,this.color=s,this._colorZone=null}static compare(e,t){return e.color===t.color?e.startLineNumber===t.startLineNumber?e.heightInLines===t.heightInLines?e.endLineNumber-t.endLineNumber:e.heightInLines-t.heightInLines:e.startLineNumber-t.startLineNumber:e.colori&&(g=i-p);const m=l.color;let f=this._color2Id[m];f||(f=++this._lastAssignedId,this._color2Id[m]=f,this._id2Color[f]=m);const _=new s(g-p,g+p,f);l.setColorZone(_),o.push(_)}return this._colorZonesInvalid=!1,o.sort(s.compare),o}}},32398:(e,t,i)=>{"use strict";i.d(t,{GN:()=>l,UB:()=>a,a6:()=>c,wc:()=>h});var s=i(83069),n=i(36677),r=i(92896),o=i(87908);class a{constructor(e,t,i,s,n){this.editorId=e,this.model=t,this.configuration=i,this._linesCollection=s,this._coordinatesConverter=n,this._decorationsCache=Object.create(null),this._cachedModelDecorationsResolver=null,this._cachedModelDecorationsResolverViewRange=null}_clearCachedModelDecorationsResolver(){this._cachedModelDecorationsResolver=null,this._cachedModelDecorationsResolverViewRange=null}dispose(){this._decorationsCache=Object.create(null),this._clearCachedModelDecorationsResolver()}reset(){this._decorationsCache=Object.create(null),this._clearCachedModelDecorationsResolver()}onModelDecorationsChanged(){this._decorationsCache=Object.create(null),this._clearCachedModelDecorationsResolver()}onLineMappingChanged(){this._decorationsCache=Object.create(null),this._clearCachedModelDecorationsResolver()}_getOrCreateViewModelDecoration(e){const t=e.id;let i=this._decorationsCache[t];if(!i){const o=e.range,a=e.options;let l;if(a.isWholeLine){const e=this._coordinatesConverter.convertModelPositionToViewPosition(new s.y(o.startLineNumber,1),0,!1,!0),t=this._coordinatesConverter.convertModelPositionToViewPosition(new s.y(o.endLineNumber,this.model.getLineMaxColumn(o.endLineNumber)),1);l=new n.Q(e.lineNumber,e.column,t.lineNumber,t.column)}else l=this._coordinatesConverter.convertModelRangeToViewRange(o,1);i=new r.vo(l,a),this._decorationsCache[t]=i}return i}getMinimapDecorationsInRange(e){return this._getDecorationsInRange(e,!0,!1).decorations}getDecorationsViewportData(e){let t=null!==this._cachedModelDecorationsResolver;return t=t&&e.equalsRange(this._cachedModelDecorationsResolverViewRange),t||(this._cachedModelDecorationsResolver=this._getDecorationsInRange(e,!1,!1),this._cachedModelDecorationsResolverViewRange=e),this._cachedModelDecorationsResolver}getInlineDecorationsOnLine(e,t=!1,i=!1){const s=new n.Q(e,this._linesCollection.getViewLineMinColumn(e),e,this._linesCollection.getViewLineMaxColumn(e));return this._getDecorationsInRange(s,t,i).inlineDecorations[0]}_getDecorationsInRange(e,t,i){const s=this._linesCollection.getDecorationsInRange(e,this.editorId,(0,o.$C)(this.configuration.options),t,i),a=e.startLineNumber,c=e.endLineNumber,h=[];let d=0;const u=[];for(let n=a;n<=c;n++)u[n-a]=[];for(let o=0,g=s.length;o1===e))}function h(e,t){return d(e,t.range,(e=>2===e))}function d(e,t,i){for(let s=t.startLineNumber;s<=t.endLineNumber;s++){const n=e.tokenization.getLineTokens(s),r=s===t.startLineNumber,o=s===t.endLineNumber;let a=r?n.findTokenIndexAtOffset(t.startColumn-1):0;for(;at.endColumn-1)break}if(!i(n.getStandardTokenType(a)))return!1;a++}}return!0}},44915:(e,t,i)=>{"use strict";var s,n=i(11007),r=i(16980),o=i(24939),a=i(31450),l=i(75326),c=i(60002),h=i(78209),d=i(32848),u=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};const p=new d.N1("selectionAnchorSet",!1);let m=class{static{s=this}static{this.ID="editor.contrib.selectionAnchorController"}static get(e){return e.getContribution(s.ID)}constructor(e,t){this.editor=e,this.selectionAnchorSetContextKey=p.bindTo(t),this.modelChangeListener=e.onDidChangeModel((()=>this.selectionAnchorSetContextKey.reset()))}setSelectionAnchor(){if(this.editor.hasModel()){const e=this.editor.getPosition();this.editor.changeDecorations((t=>{this.decorationId&&t.removeDecoration(this.decorationId),this.decorationId=t.addDecoration(l.L.fromPositions(e,e),{description:"selection-anchor",stickiness:1,hoverMessage:(new r.Bc).appendText((0,h.kg)("selectionAnchor","Selection Anchor")),className:"selection-anchor"})})),this.selectionAnchorSetContextKey.set(!!this.decorationId),(0,n.xE)((0,h.kg)("anchorSet","Anchor set at {0}:{1}",e.lineNumber,e.column))}}goToSelectionAnchor(){if(this.editor.hasModel()&&this.decorationId){const e=this.editor.getModel().getDecorationRange(this.decorationId);e&&this.editor.setPosition(e.getStartPosition())}}selectFromAnchorToCursor(){if(this.editor.hasModel()&&this.decorationId){const e=this.editor.getModel().getDecorationRange(this.decorationId);if(e){const t=this.editor.getPosition();this.editor.setSelection(l.L.fromPositions(e.getStartPosition(),t)),this.cancelSelectionAnchor()}}}cancelSelectionAnchor(){if(this.decorationId){const e=this.decorationId;this.editor.changeDecorations((t=>{t.removeDecoration(e),this.decorationId=void 0})),this.selectionAnchorSetContextKey.set(!1)}}dispose(){this.cancelSelectionAnchor(),this.modelChangeListener.dispose()}};m=s=u([g(1,d.fN)],m);class f extends a.ks{constructor(){super({id:"editor.action.setSelectionAnchor",label:(0,h.kg)("setSelectionAnchor","Set Selection Anchor"),alias:"Set Selection Anchor",precondition:void 0,kbOpts:{kbExpr:c.R.editorTextFocus,primary:(0,o.m5)(2089,2080),weight:100}})}async run(e,t){m.get(t)?.setSelectionAnchor()}}class _ extends a.ks{constructor(){super({id:"editor.action.goToSelectionAnchor",label:(0,h.kg)("goToSelectionAnchor","Go to Selection Anchor"),alias:"Go to Selection Anchor",precondition:p})}async run(e,t){m.get(t)?.goToSelectionAnchor()}}class v extends a.ks{constructor(){super({id:"editor.action.selectFromAnchorToCursor",label:(0,h.kg)("selectFromAnchorToCursor","Select from Anchor to Cursor"),alias:"Select from Anchor to Cursor",precondition:p,kbOpts:{kbExpr:c.R.editorTextFocus,primary:(0,o.m5)(2089,2089),weight:100}})}async run(e,t){m.get(t)?.selectFromAnchorToCursor()}}class C extends a.ks{constructor(){super({id:"editor.action.cancelSelectionAnchor",label:(0,h.kg)("cancelSelectionAnchor","Cancel Selection Anchor"),alias:"Cancel Selection Anchor",precondition:p,kbOpts:{kbExpr:c.R.editorTextFocus,primary:9,weight:100}})}async run(e,t){m.get(t)?.cancelSelectionAnchor()}}(0,a.HW)(m.ID,m,4),(0,a.Fl)(f),(0,a.Fl)(_),(0,a.Fl)(v),(0,a.Fl)(C)},88952:(e,t,i)=>{"use strict";var s=i(90766),n=i(5662),r=i(31450),o=i(83069),a=i(36677),l=i(75326),c=i(60002),h=i(16223),d=i(87289),u=i(78209),g=i(27195),p=i(66261),m=i(47612);const f=(0,p.x1A)("editorOverviewRuler.bracketMatchForeground","#A0A0A0",u.kg("overviewRulerBracketMatchForeground","Overview ruler marker color for matching brackets."));class _ extends r.ks{constructor(){super({id:"editor.action.jumpToBracket",label:u.kg("smartSelect.jumpBracket","Go to Bracket"),alias:"Go to Bracket",precondition:void 0,kbOpts:{kbExpr:c.R.editorTextFocus,primary:3165,weight:100}})}run(e,t){E.get(t)?.jumpToBracket()}}class v extends r.ks{constructor(){super({id:"editor.action.selectToBracket",label:u.kg("smartSelect.selectToBracket","Select to Bracket"),alias:"Select to Bracket",precondition:void 0,metadata:{description:u.aS("smartSelect.selectToBracketDescription","Select the text inside and including the brackets or curly braces"),args:[{name:"args",schema:{type:"object",properties:{selectBrackets:{type:"boolean",default:!0}}}}]}})}run(e,t,i){let s=!0;i&&!1===i.selectBrackets&&(s=!1),E.get(t)?.selectToBracket(s)}}class C extends r.ks{constructor(){super({id:"editor.action.removeBrackets",label:u.kg("smartSelect.removeBrackets","Remove Brackets"),alias:"Remove Brackets",precondition:void 0,kbOpts:{kbExpr:c.R.editorTextFocus,primary:2561,weight:100}})}run(e,t){E.get(t)?.removeBrackets(this.id)}}class b{constructor(e,t,i){this.position=e,this.brackets=t,this.options=i}}class E extends n.jG{static{this.ID="editor.contrib.bracketMatchingController"}static get(e){return e.getContribution(E.ID)}constructor(e){super(),this._editor=e,this._lastBracketsData=[],this._lastVersionId=0,this._decorations=this._editor.createDecorationsCollection(),this._updateBracketsSoon=this._register(new s.uC((()=>this._updateBrackets()),50)),this._matchBrackets=this._editor.getOption(72),this._updateBracketsSoon.schedule(),this._register(e.onDidChangeCursorPosition((e=>{"never"!==this._matchBrackets&&this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeModelContent((e=>{this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeModel((e=>{this._lastBracketsData=[],this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeModelLanguageConfiguration((e=>{this._lastBracketsData=[],this._updateBracketsSoon.schedule()}))),this._register(e.onDidChangeConfiguration((e=>{e.hasChanged(72)&&(this._matchBrackets=this._editor.getOption(72),this._decorations.clear(),this._lastBracketsData=[],this._lastVersionId=0,this._updateBracketsSoon.schedule())}))),this._register(e.onDidBlurEditorWidget((()=>{this._updateBracketsSoon.schedule()}))),this._register(e.onDidFocusEditorWidget((()=>{this._updateBracketsSoon.schedule()})))}jumpToBracket(){if(!this._editor.hasModel())return;const e=this._editor.getModel(),t=this._editor.getSelections().map((t=>{const i=t.getStartPosition(),s=e.bracketPairs.matchBracket(i);let n=null;if(s)s[0].containsPosition(i)&&!s[1].containsPosition(i)?n=s[1].getStartPosition():s[1].containsPosition(i)&&(n=s[0].getStartPosition());else{const t=e.bracketPairs.findEnclosingBrackets(i);if(t)n=t[1].getStartPosition();else{const t=e.bracketPairs.findNextBracket(i);t&&t.range&&(n=t.range.getStartPosition())}}return n?new l.L(n.lineNumber,n.column,n.lineNumber,n.column):new l.L(i.lineNumber,i.column,i.lineNumber,i.column)}));this._editor.setSelections(t),this._editor.revealRange(t[0])}selectToBracket(e){if(!this._editor.hasModel())return;const t=this._editor.getModel(),i=[];this._editor.getSelections().forEach((s=>{const n=s.getStartPosition();let r=t.bracketPairs.matchBracket(n);if(!r&&(r=t.bracketPairs.findEnclosingBrackets(n),!r)){const e=t.bracketPairs.findNextBracket(n);e&&e.range&&(r=t.bracketPairs.matchBracket(e.range.getStartPosition()))}let o=null,c=null;if(r){r.sort(a.Q.compareRangesUsingStarts);const[t,i]=r;if(o=e?t.getStartPosition():t.getEndPosition(),c=e?i.getEndPosition():i.getStartPosition(),i.containsPosition(n)){const e=o;o=c,c=e}}o&&c&&i.push(new l.L(o.lineNumber,o.column,c.lineNumber,c.column))})),i.length>0&&(this._editor.setSelections(i),this._editor.revealRange(i[0]))}removeBrackets(e){if(!this._editor.hasModel())return;const t=this._editor.getModel();this._editor.getSelections().forEach((i=>{const s=i.getPosition();let n=t.bracketPairs.matchBracket(s);n||(n=t.bracketPairs.findEnclosingBrackets(s)),n&&(this._editor.pushUndoStop(),this._editor.executeEdits(e,[{range:n[0],text:""},{range:n[1],text:""}]),this._editor.pushUndoStop())}))}static{this._DECORATION_OPTIONS_WITH_OVERVIEW_RULER=d.kI.register({description:"bracket-match-overview",stickiness:1,className:"bracket-match",overviewRuler:{color:(0,m.Yf)(f),position:h.A5.Center}})}static{this._DECORATION_OPTIONS_WITHOUT_OVERVIEW_RULER=d.kI.register({description:"bracket-match-no-overview",stickiness:1,className:"bracket-match"})}_updateBrackets(){if("never"===this._matchBrackets)return;this._recomputeBrackets();const e=[];let t=0;for(const i of this._lastBracketsData){const s=i.brackets;s&&(e[t++]={range:s[0],options:i.options},e[t++]={range:s[1],options:i.options})}this._decorations.set(e)}_recomputeBrackets(){if(!this._editor.hasModel()||!this._editor.hasWidgetFocus())return this._lastBracketsData=[],void(this._lastVersionId=0);const e=this._editor.getSelections();if(e.length>100)return this._lastBracketsData=[],void(this._lastVersionId=0);const t=this._editor.getModel(),i=t.getVersionId();let s=[];this._lastVersionId===i&&(s=this._lastBracketsData);const n=[];let r=0;for(let o=0,d=e.length;o1&&n.sort(o.y.compare);const a=[];let l=0,c=0;const h=s.length;for(let o=0,d=n.length;o{"use strict";var s=i(31450),n=i(60002),r=i(36677),o=i(75326);class a{constructor(e,t){this._selection=e,this._isMovingLeft=t}getEditOperations(e,t){if(this._selection.startLineNumber!==this._selection.endLineNumber||this._selection.isEmpty())return;const i=this._selection.startLineNumber,s=this._selection.startColumn,n=this._selection.endColumn;if((!this._isMovingLeft||1!==s)&&(this._isMovingLeft||n!==e.getLineMaxColumn(i)))if(this._isMovingLeft){const o=new r.Q(i,s-1,i,s),a=e.getValueInRange(o);t.addEditOperation(o,null),t.addEditOperation(new r.Q(i,n,i,n),a)}else{const o=new r.Q(i,n,i,n+1),a=e.getValueInRange(o);t.addEditOperation(o,null),t.addEditOperation(new r.Q(i,s,i,s),a)}}computeCursorState(e,t){return this._isMovingLeft?new o.L(this._selection.startLineNumber,this._selection.startColumn-1,this._selection.endLineNumber,this._selection.endColumn-1):new o.L(this._selection.startLineNumber,this._selection.startColumn+1,this._selection.endLineNumber,this._selection.endColumn+1)}}var l=i(78209);class c extends s.ks{constructor(e,t){super(t),this.left=e}run(e,t){if(!t.hasModel())return;const i=[],s=t.getSelections();for(const n of s)i.push(new a(n,this.left));t.pushUndoStop(),t.executeCommands(this.id,i),t.pushUndoStop()}}(0,s.Fl)(class extends c{constructor(){super(!0,{id:"editor.action.moveCarretLeftAction",label:l.kg("caret.moveLeft","Move Selected Text Left"),alias:"Move Selected Text Left",precondition:n.R.writable})}}),(0,s.Fl)(class extends c{constructor(){super(!1,{id:"editor.action.moveCarretRightAction",label:l.kg("caret.moveRight","Move Selected Text Right"),alias:"Move Selected Text Right",precondition:n.R.writable})}})},6438:(e,t,i)=>{"use strict";var s=i(31450),n=i(15092),r=i(94564),o=i(36677),a=i(60002),l=i(78209);class c extends s.ks{constructor(){super({id:"editor.action.transposeLetters",label:l.kg("transposeLetters.label","Transpose Letters"),alias:"Transpose Letters",precondition:a.R.writable,kbOpts:{kbExpr:a.R.textInputFocus,primary:0,mac:{primary:306},weight:100}})}run(e,t){if(!t.hasModel())return;const i=t.getModel(),s=[],a=t.getSelections();for(const l of a){if(!l.isEmpty())continue;const e=l.startLineNumber,t=l.startColumn,a=i.getLineMaxColumn(e);if(1===e&&(1===t||2===t&&2===a))continue;const c=t===a?l.getPosition():r.I.rightPosition(i,l.getPosition().lineNumber,l.getPosition().column),h=r.I.leftPosition(i,c),d=r.I.leftPosition(i,h),u=i.getValueInRange(o.Q.fromPositions(d,h)),g=i.getValueInRange(o.Q.fromPositions(h,c)),p=o.Q.fromPositions(d,c);s.push(new n.iu(p,g+u))}s.length>0&&(t.pushUndoStop(),t.executeCommands(this.id,s),t.pushUndoStop())}}(0,s.Fl)(c)},94908:(e,t,i)=>{"use strict";var s=i(60413),n=i(8597),r=i(98067),o=i(68792),a=i(31450),l=i(80301),c=i(60002),h=i(55433),d=i(78209),u=i(27195),g=i(54770),p=i(32848);const m="9_cutcopypaste",f=r.ib||document.queryCommandSupported("cut"),_=r.ib||document.queryCommandSupported("copy"),v="undefined"!==typeof navigator.clipboard&&!s.gm||document.queryCommandSupported("paste");function C(e){return e.register(),e}const b=f?C(new a.fE({id:"editor.action.clipboardCutAction",precondition:void 0,kbOpts:r.ib?{primary:2102,win:{primary:2102,secondary:[1044]},weight:100}:void 0,menuOpts:[{menuId:u.D8.MenubarEditMenu,group:"2_ccp",title:d.kg({key:"miCut",comment:["&& denotes a mnemonic"]},"Cu&&t"),order:1},{menuId:u.D8.EditorContext,group:m,title:d.kg("actions.clipboard.cutLabel","Cut"),when:c.R.writable,order:1},{menuId:u.D8.CommandPalette,group:"",title:d.kg("actions.clipboard.cutLabel","Cut"),order:1},{menuId:u.D8.SimpleEditorContext,group:m,title:d.kg("actions.clipboard.cutLabel","Cut"),when:c.R.writable,order:1}]})):void 0,E=_?C(new a.fE({id:"editor.action.clipboardCopyAction",precondition:void 0,kbOpts:r.ib?{primary:2081,win:{primary:2081,secondary:[2067]},weight:100}:void 0,menuOpts:[{menuId:u.D8.MenubarEditMenu,group:"2_ccp",title:d.kg({key:"miCopy",comment:["&& denotes a mnemonic"]},"&&Copy"),order:2},{menuId:u.D8.EditorContext,group:m,title:d.kg("actions.clipboard.copyLabel","Copy"),order:2},{menuId:u.D8.CommandPalette,group:"",title:d.kg("actions.clipboard.copyLabel","Copy"),order:1},{menuId:u.D8.SimpleEditorContext,group:m,title:d.kg("actions.clipboard.copyLabel","Copy"),order:2}]})):void 0;u.ZG.appendMenuItem(u.D8.MenubarEditMenu,{submenu:u.D8.MenubarCopy,title:d.aS("copy as","Copy As"),group:"2_ccp",order:3}),u.ZG.appendMenuItem(u.D8.EditorContext,{submenu:u.D8.EditorContextCopy,title:d.aS("copy as","Copy As"),group:m,order:3}),u.ZG.appendMenuItem(u.D8.EditorContext,{submenu:u.D8.EditorContextShare,title:d.aS("share","Share"),group:"11_share",order:-1,when:p.M$.and(p.M$.notEquals("resourceScheme","output"),c.R.editorTextFocus)}),u.ZG.appendMenuItem(u.D8.ExplorerContext,{submenu:u.D8.ExplorerContextShare,title:d.aS("share","Share"),group:"11_share",order:-1});const S=v?C(new a.fE({id:"editor.action.clipboardPasteAction",precondition:void 0,kbOpts:r.ib?{primary:2100,win:{primary:2100,secondary:[1043]},linux:{primary:2100,secondary:[1043]},weight:100}:void 0,menuOpts:[{menuId:u.D8.MenubarEditMenu,group:"2_ccp",title:d.kg({key:"miPaste",comment:["&& denotes a mnemonic"]},"&&Paste"),order:4},{menuId:u.D8.EditorContext,group:m,title:d.kg("actions.clipboard.pasteLabel","Paste"),when:c.R.writable,order:4},{menuId:u.D8.CommandPalette,group:"",title:d.kg("actions.clipboard.pasteLabel","Paste"),order:1},{menuId:u.D8.SimpleEditorContext,group:m,title:d.kg("actions.clipboard.pasteLabel","Paste"),when:c.R.writable,order:4}]})):void 0;class y extends a.ks{constructor(){super({id:"editor.action.clipboardCopyWithSyntaxHighlightingAction",label:d.kg("actions.clipboard.copyWithSyntaxHighlightingLabel","Copy With Syntax Highlighting"),alias:"Copy With Syntax Highlighting",precondition:void 0,kbOpts:{kbExpr:c.R.textInputFocus,primary:0,weight:100}})}run(e,t){if(!t.hasModel())return;!t.getOption(37)&&t.getSelection().isEmpty()||(o.Eq.forceCopyWithSyntaxHighlighting=!0,t.focus(),t.getContainerDomNode().ownerDocument.execCommand("copy"),o.Eq.forceCopyWithSyntaxHighlighting=!1)}}function w(e,t){e&&(e.addImplementation(1e4,"code-editor",((e,i)=>{const s=e.get(l.T).getFocusedCodeEditor();if(s&&s.hasTextFocus()){const e=s.getOption(37),i=s.getSelection();return i&&i.isEmpty()&&!e||s.getContainerDomNode().ownerDocument.execCommand(t),!0}return!1})),e.addImplementation(0,"generic-dom",((e,i)=>((0,n.a)().execCommand(t),!0))))}w(b,"cut"),w(E,"copy"),S&&(S.addImplementation(1e4,"code-editor",((e,t)=>{const i=e.get(l.T),s=e.get(g.h),n=i.getFocusedCodeEditor();if(n&&n.hasTextFocus()){return n.getContainerDomNode().ownerDocument.execCommand("paste")?h.Rj.get(n)?.finishedPaste()??Promise.resolve():!r.HZ||(async()=>{const e=await s.readText();if(""!==e){const t=o.bs.INSTANCE.get(e);let i=!1,s=null,r=null;t&&(i=n.getOption(37)&&!!t.isFromEmptySelection,s="undefined"!==typeof t.multicursorText?t.multicursorText:null,r=t.mode),n.trigger("keyboard","paste",{text:e,pasteOnNewLine:i,multicursorText:s,mode:r})}})()}return!1})),S.addImplementation(0,"generic-dom",((e,t)=>((0,n.a)().execCommand("paste"),!0)))),_&&(0,a.Fl)(y)},55130:(e,t,i)=>{"use strict";i.d(t,{C9:()=>L,Qp:()=>I,Rw:()=>T,Uy:()=>R,W4:()=>O,Xj:()=>w,dU:()=>A,k_:()=>E,pQ:()=>S,pR:()=>y});var s=i(25890),n=i(18447),r=i(64383),o=i(5662),a=i(79400),l=i(80537),c=i(36677),h=i(75326),d=i(56942),u=i(23750),g=i(50868),p=i(78209),m=i(50091),f=i(58591),_=i(73823),v=i(90651),C=i(61407),b=i(8995);const E="editor.action.codeAction",S="editor.action.quickFix",y="editor.action.autoFix",w="editor.action.refactor",L="editor.action.sourceAction",R="editor.action.organizeImports",T="editor.action.fixAll";class x extends o.jG{static codeActionsPreferredComparator(e,t){return e.isPreferred&&!t.isPreferred?-1:!e.isPreferred&&t.isPreferred?1:0}static codeActionsComparator({action:e},{action:t}){return e.isAI&&!t.isAI?1:!e.isAI&&t.isAI?-1:(0,s.EI)(e.diagnostics)?(0,s.EI)(t.diagnostics)?x.codeActionsPreferredComparator(e,t):-1:(0,s.EI)(t.diagnostics)?1:x.codeActionsPreferredComparator(e,t)}constructor(e,t,i){super(),this.documentation=t,this._register(i),this.allActions=[...e].sort(x.codeActionsComparator),this.validActions=this.allActions.filter((({action:e})=>!e.disabled))}get hasAutoFix(){return this.validActions.some((({action:e})=>!!e.kind&&C.gB.QuickFix.contains(new b.k(e.kind))&&!!e.isPreferred))}get hasAIFix(){return this.validActions.some((({action:e})=>!!e.isAI))}get allAIFixes(){return this.validActions.every((({action:e})=>!!e.isAI))}}const k={actions:[],documentation:void 0};async function A(e,t,i,n,a,l){const c=n.filter||{},h={...c,excludes:[...c.excludes||[],C.gB.Notebook]},d={only:c.include?.value,trigger:n.type},u=new g.ER(t,l),p=2===n.type,m=function(e,t,i){return e.all(t).filter((e=>!e.providedCodeActionKinds||e.providedCodeActionKinds.some((e=>(0,C.uJ)(i,new b.k(e))))))}(e,t,p?h:c),f=new o.Cm,_=m.map((async e=>{try{a.report(e);const s=await e.provideCodeActions(t,i,d,u.token);if(s&&f.add(s),u.token.isCancellationRequested)return k;const n=(s?.actions||[]).filter((e=>e&&(0,C.aF)(c,e))),r=function(e,t,i){if(!e.documentation)return;const s=e.documentation.map((e=>({kind:new b.k(e.kind),command:e.command})));if(i){let e;for(const t of s)t.kind.contains(i)&&(e?e.kind.contains(t.kind)&&(e=t):e=t);if(e)return e?.command}for(const n of t)if(n.kind)for(const e of s)if(e.kind.contains(new b.k(n.kind)))return e.command;return}(e,n,c.include);return{actions:n.map((t=>new C.Vi(t,e))),documentation:r}}catch(s){if((0,r.MB)(s))throw s;return(0,r.M_)(s),k}})),v=e.onDidChange((()=>{const i=e.all(t);(0,s.aI)(i,m)||u.cancel()}));try{const i=await Promise.all(_),r=i.map((e=>e.actions)).flat(),o=[...(0,s.Yc)(i.map((e=>e.documentation))),...N(e,t,n,r)];return new x(r,o,f)}finally{v.dispose(),u.dispose()}}function*N(e,t,i,s){if(t&&s.length)for(const n of e.all(t))n._getAdditionalMenuItems&&(yield*n._getAdditionalMenuItems?.({trigger:i.type,only:i.filter?.include?.value},s.map((e=>e.action))))}var I;async function O(e,t,i,s,r=n.XO.None){const o=e.get(l.nu),a=e.get(m.d),c=e.get(v.k),h=e.get(f.Ot);if(c.publicLog2("codeAction.applyCodeAction",{codeActionTitle:t.action.title,codeActionKind:t.action.kind,codeActionIsPreferred:!!t.action.isPreferred,reason:i}),await t.resolve(r),!r.isCancellationRequested){if(t.action.edit?.edits.length){if(!(await o.apply(t.action.edit,{editor:s?.editor,label:t.action.title,quotableLabel:t.action.title,code:"undoredo.codeAction",respectAutoSaveConfig:i!==I.OnSave,showPreview:s?.preview})).isApplied)return}if(t.action.command)try{await a.executeCommand(t.action.command.id,...t.action.command.arguments||[])}catch(d){const e=function(e){return"string"===typeof e?e:e instanceof Error&&"string"===typeof e.message?e.message:void 0}(d);h.error("string"===typeof e?e:p.kg("applyCodeActionFailed","An unknown error occurred while applying the code action"))}}}!function(e){e.OnSave="onSave",e.FromProblemsView="fromProblemsView",e.FromCodeActions="fromCodeActions",e.FromAILightbulb="fromAILightbulb"}(I||(I={})),m.w.registerCommand("_executeCodeActionProvider",(async function(e,t,i,s,o){if(!(t instanceof a.r))throw(0,r.Qg)();const{codeActionProvider:l}=e.get(d.ILanguageFeaturesService),g=e.get(u.IModelService).getModel(t);if(!g)throw(0,r.Qg)();const p=h.L.isISelection(i)?h.L.liftSelection(i):c.Q.isIRange(i)?g.validateRange(i):void 0;if(!p)throw(0,r.Qg)();const m="string"===typeof s?new b.k(s):void 0,f=await A(l,g,p,{type:1,triggerAction:C.fo.Default,filter:{includeSourceActions:!0,include:m}},_.ke.None,n.XO.None),v=[],E=Math.min(f.validActions.length,"number"===typeof o?o:0);for(let r=0;re.action))}finally{setTimeout((()=>f.dispose()),100)}}))},4836:(e,t,i)=>{"use strict";var s=i(31450),n=i(94371),r=i(8995),o=i(91508),a=i(60002),l=i(55130),c=i(78209),h=i(32848),d=i(61407),u=i(71933),g=i(59473);function p(e){return h.M$.regex(g.D_.keys()[0],new RegExp("(\\s|^)"+(0,o.bm)(e.value)+"\\b"))}const m={type:"object",defaultSnippets:[{body:{kind:""}}],properties:{kind:{type:"string",description:c.kg("args.schema.kind","Kind of the code action to run.")},apply:{type:"string",description:c.kg("args.schema.apply","Controls when the returned actions are applied."),default:"ifSingle",enum:["first","ifSingle","never"],enumDescriptions:[c.kg("args.schema.apply.first","Always apply the first returned code action."),c.kg("args.schema.apply.ifSingle","Apply the first returned code action if it is the only one."),c.kg("args.schema.apply.never","Do not apply the returned code actions.")]},preferred:{type:"boolean",default:!1,description:c.kg("args.schema.preferred","Controls if only preferred code actions should be returned.")}}};function f(e,t,i,s,n=d.fo.Default){if(e.hasModel()){const r=u.C.get(e);r?.manualTriggerAtCurrentPosition(t,n,i,s)}}class _ extends s.ks{constructor(){super({id:l.pQ,label:c.kg("quickfix.trigger.label","Quick Fix..."),alias:"Quick Fix...",precondition:h.M$.and(a.R.writable,a.R.hasCodeActionsProvider),kbOpts:{kbExpr:a.R.textInputFocus,primary:2137,weight:100}})}run(e,t){return f(t,c.kg("editor.action.quickFix.noneMessage","No code actions available"),void 0,void 0,d.fo.QuickFix)}}class v extends s.DX{constructor(){super({id:l.k_,precondition:h.M$.and(a.R.writable,a.R.hasCodeActionsProvider),metadata:{description:"Trigger a code action",args:[{name:"args",schema:m}]}})}runEditorCommand(e,t,i){const s=d.QA.fromUser(i,{kind:r.k.Empty,apply:"ifSingle"});return f(t,"string"===typeof i?.kind?s.preferred?c.kg("editor.action.codeAction.noneMessage.preferred.kind","No preferred code actions for '{0}' available",i.kind):c.kg("editor.action.codeAction.noneMessage.kind","No code actions for '{0}' available",i.kind):s.preferred?c.kg("editor.action.codeAction.noneMessage.preferred","No preferred code actions available"):c.kg("editor.action.codeAction.noneMessage","No code actions available"),{include:s.kind,includeSourceActions:!0,onlyIncludePreferredActions:s.preferred},s.apply)}}class C extends s.ks{constructor(){super({id:l.Xj,label:c.kg("refactor.label","Refactor..."),alias:"Refactor...",precondition:h.M$.and(a.R.writable,a.R.hasCodeActionsProvider),kbOpts:{kbExpr:a.R.textInputFocus,primary:3120,mac:{primary:1328},weight:100},contextMenuOpts:{group:"1_modification",order:2,when:h.M$.and(a.R.writable,p(d.gB.Refactor))},metadata:{description:"Refactor...",args:[{name:"args",schema:m}]}})}run(e,t,i){const s=d.QA.fromUser(i,{kind:d.gB.Refactor,apply:"never"});return f(t,"string"===typeof i?.kind?s.preferred?c.kg("editor.action.refactor.noneMessage.preferred.kind","No preferred refactorings for '{0}' available",i.kind):c.kg("editor.action.refactor.noneMessage.kind","No refactorings for '{0}' available",i.kind):s.preferred?c.kg("editor.action.refactor.noneMessage.preferred","No preferred refactorings available"):c.kg("editor.action.refactor.noneMessage","No refactorings available"),{include:d.gB.Refactor.contains(s.kind)?s.kind:r.k.None,onlyIncludePreferredActions:s.preferred},s.apply,d.fo.Refactor)}}class b extends s.ks{constructor(){super({id:l.C9,label:c.kg("source.label","Source Action..."),alias:"Source Action...",precondition:h.M$.and(a.R.writable,a.R.hasCodeActionsProvider),contextMenuOpts:{group:"1_modification",order:2.1,when:h.M$.and(a.R.writable,p(d.gB.Source))},metadata:{description:"Source Action...",args:[{name:"args",schema:m}]}})}run(e,t,i){const s=d.QA.fromUser(i,{kind:d.gB.Source,apply:"never"});return f(t,"string"===typeof i?.kind?s.preferred?c.kg("editor.action.source.noneMessage.preferred.kind","No preferred source actions for '{0}' available",i.kind):c.kg("editor.action.source.noneMessage.kind","No source actions for '{0}' available",i.kind):s.preferred?c.kg("editor.action.source.noneMessage.preferred","No preferred source actions available"):c.kg("editor.action.source.noneMessage","No source actions available"),{include:d.gB.Source.contains(s.kind)?s.kind:r.k.None,includeSourceActions:!0,onlyIncludePreferredActions:s.preferred},s.apply,d.fo.SourceAction)}}class E extends s.ks{constructor(){super({id:l.Uy,label:c.kg("organizeImports.label","Organize Imports"),alias:"Organize Imports",precondition:h.M$.and(a.R.writable,p(d.gB.SourceOrganizeImports)),kbOpts:{kbExpr:a.R.textInputFocus,primary:1581,weight:100}})}run(e,t){return f(t,c.kg("editor.action.organize.noneMessage","No organize imports action available"),{include:d.gB.SourceOrganizeImports,includeSourceActions:!0},"ifSingle",d.fo.OrganizeImports)}}class S extends s.ks{constructor(){super({id:l.Rw,label:c.kg("fixAll.label","Fix All"),alias:"Fix All",precondition:h.M$.and(a.R.writable,p(d.gB.SourceFixAll))})}run(e,t){return f(t,c.kg("fixAll.noneMessage","No fix all action available"),{include:d.gB.SourceFixAll,includeSourceActions:!0},"ifSingle",d.fo.FixAll)}}class y extends s.ks{constructor(){super({id:l.pR,label:c.kg("autoFix.label","Auto Fix..."),alias:"Auto Fix...",precondition:h.M$.and(a.R.writable,p(d.gB.QuickFix)),kbOpts:{kbExpr:a.R.textInputFocus,primary:1625,mac:{primary:2649},weight:100}})}run(e,t){return f(t,c.kg("editor.action.autoFix.noneMessage","No auto fixes available"),{include:d.gB.QuickFix,onlyIncludePreferredActions:!0},"ifSingle",d.fo.AutoFix)}}var w=i(96758),L=i(1646),R=i(46359);(0,s.HW)(u.C.ID,u.C,3),(0,s.HW)(w.E.ID,w.E,4),(0,s.Fl)(_),(0,s.Fl)(C),(0,s.Fl)(b),(0,s.Fl)(E),(0,s.Fl)(y),(0,s.Fl)(S),(0,s.E_)(new v),R.O.as(L.Fd.Configuration).registerConfiguration({...n.JJ,properties:{"editor.codeActionWidget.showHeaders":{type:"boolean",scope:5,description:c.kg("showCodeActionHeaders","Enable/disable showing group headers in the Code Action menu."),default:!0}}}),R.O.as(L.Fd.Configuration).registerConfiguration({...n.JJ,properties:{"editor.codeActionWidget.includeNearbyQuickFixes":{type:"boolean",scope:5,description:c.kg("includeNearbyQuickFixes","Enable/disable showing nearest Quick Fix within a line when not currently on a diagnostic."),default:!0}}}),R.O.as(L.Fd.Configuration).registerConfiguration({...n.JJ,properties:{"editor.codeActions.triggerOnFocusChange":{type:"boolean",scope:5,markdownDescription:c.kg("triggerOnFocusChange","Enable triggering {0} when {1} is set to {2}. Code Actions must be set to {3} to be triggered for window and focus changes.","`#editor.codeActionsOnSave#`","`#files.autoSave#`","`afterDelay`","`always`"),default:!1}}})},71933:(e,t,i)=>{"use strict";i.d(t,{C:()=>ue});var s,n=i(8597),r=i(11007),o=i(64383),a=i(91090),l=i(5662),c=i(83069),h=i(87289),d=i(56942),u=i(55130),g=i(8995),p=i(61407),m=i(98031),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class{static{s=this}static{this.codeActionCommands=[u.Xj,u.k_,u.C9,u.Uy,u.Rw]}constructor(e){this.keybindingService=e}getResolver(){const e=new a.d((()=>this.keybindingService.getKeybindings().filter((e=>s.codeActionCommands.indexOf(e.command)>=0)).filter((e=>e.resolvedKeybinding)).map((e=>{let t=e.commandArgs;return e.command===u.Uy?t={kind:p.gB.SourceOrganizeImports.value}:e.command===u.Rw&&(t={kind:p.gB.SourceFixAll.value}),{resolvedKeybinding:e.resolvedKeybinding,...p.QA.fromUser(t,{kind:g.k.None,apply:"never"})}}))));return t=>{if(t.kind){const i=this.bestKeybindingForCodeAction(t,e.value);return i?.resolvedKeybinding}}}bestKeybindingForCodeAction(e,t){if(!e.kind)return;const i=new g.k(e.kind);return t.filter((e=>e.kind.contains(i))).filter((t=>!t.preferred||e.isPreferred)).reduceRight(((e,t)=>e?e.kind.contains(t.kind)?t:e:t),void 0)}};v=s=f([_(0,m.b)],v);i(97791);var C=i(10350),b=(i(93409),i(78209));const E=Object.freeze({kind:g.k.Empty,title:(0,b.kg)("codeAction.widget.id.more","More Actions...")}),S=Object.freeze([{kind:p.gB.QuickFix,title:(0,b.kg)("codeAction.widget.id.quickfix","Quick Fix")},{kind:p.gB.RefactorExtract,title:(0,b.kg)("codeAction.widget.id.extract","Extract"),icon:C.W.wrench},{kind:p.gB.RefactorInline,title:(0,b.kg)("codeAction.widget.id.inline","Inline"),icon:C.W.wrench},{kind:p.gB.RefactorRewrite,title:(0,b.kg)("codeAction.widget.id.convert","Rewrite"),icon:C.W.wrench},{kind:p.gB.RefactorMove,title:(0,b.kg)("codeAction.widget.id.move","Move"),icon:C.W.wrench},{kind:p.gB.SurroundWith,title:(0,b.kg)("codeAction.widget.id.surround","Surround With"),icon:C.W.surroundWith},{kind:p.gB.Source,title:(0,b.kg)("codeAction.widget.id.source","Source Action"),icon:C.W.symbolFile},E]);var y=i(96758),w=i(99645),L=i(11799),R=i(47625),T=i(93090),x=i(18447),k=i(98067),A=i(25689),N=i(47508),I=i(19070),O=i(66261),D=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},M=function(e,t){return function(i,s){t(i,s,e)}};const P="acceptSelectedCodeAction",F="previewSelectedCodeAction";class U{get templateId(){return"header"}renderTemplate(e){e.classList.add("group-header");const t=document.createElement("span");return e.append(t),{container:e,text:t}}renderElement(e,t,i){i.text.textContent=e.group?.title??""}disposeTemplate(e){}}let H=class{get templateId(){return"action"}constructor(e,t){this._supportsPreview=e,this._keybindingService=t}renderTemplate(e){e.classList.add(this.templateId);const t=document.createElement("div");t.className="icon",e.append(t);const i=document.createElement("span");i.className="title",e.append(i);return{container:e,icon:t,text:i,keybinding:new R.x(e,k.OS)}}renderElement(e,t,i){if(e.group?.icon?(i.icon.className=A.L.asClassName(e.group.icon),e.group.icon.color&&(i.icon.style.color=(0,O.GuP)(e.group.icon.color.id))):(i.icon.className=A.L.asClassName(C.W.lightBulb),i.icon.style.color="var(--vscode-editorLightBulb-foreground)"),!e.item||!e.label)return;i.text.textContent=G(e.label),i.keybinding.set(e.keybinding),n.bo(!!e.keybinding,i.keybinding.element);const s=this._keybindingService.lookupKeybinding(P)?.getLabel(),r=this._keybindingService.lookupKeybinding(F)?.getLabel();i.container.classList.toggle("option-disabled",e.disabled),e.disabled?i.container.title=e.label:s&&r?this._supportsPreview&&e.canPreview?i.container.title=(0,b.kg)({key:"label-preview",comment:['placeholders are keybindings, e.g "F2 to Apply, Shift+F2 to Preview"']},"{0} to Apply, {1} to Preview",s,r):i.container.title=(0,b.kg)({key:"label",comment:['placeholder is a keybinding, e.g "F2 to Apply"']},"{0} to Apply",s):i.container.title=""}disposeTemplate(e){e.keybinding.dispose()}};H=D([M(1,m.b)],H);class B extends UIEvent{constructor(){super("acceptSelectedAction")}}class W extends UIEvent{constructor(){super("previewSelectedAction")}}function V(e){if("action"===e.kind)return e.label}let z=class extends l.jG{constructor(e,t,i,s,n,r){super(),this._delegate=s,this._contextViewService=n,this._keybindingService=r,this._actionLineHeight=24,this._headerLineHeight=26,this.cts=this._register(new x.Qi),this.domNode=document.createElement("div"),this.domNode.classList.add("actionList");const o={getHeight:e=>"header"===e.kind?this._headerLineHeight:this._actionLineHeight,getTemplateId:e=>e.kind};this._list=this._register(new T.B8(e,this.domNode,o,[new H(t,this._keybindingService),new U],{keyboardSupport:!1,typeNavigationEnabled:!0,keyboardNavigationLabelProvider:{getKeyboardNavigationLabel:V},accessibilityProvider:{getAriaLabel:e=>{if("action"===e.kind){let t=e.label?G(e?.label):"";return e.disabled&&(t=(0,b.kg)({key:"customQuickFixWidget.labels",comment:["Action widget labels for accessibility."]},"{0}, Disabled Reason: {1}",t,e.disabled)),t}return null},getWidgetAriaLabel:()=>(0,b.kg)({key:"customQuickFixWidget",comment:["An action widget option"]},"Action Widget"),getRole:e=>"action"===e.kind?"option":"separator",getWidgetRole:()=>"listbox"}})),this._list.style(I.IN),this._register(this._list.onMouseClick((e=>this.onListClick(e)))),this._register(this._list.onMouseOver((e=>this.onListHover(e)))),this._register(this._list.onDidChangeFocus((()=>this.onFocus()))),this._register(this._list.onDidChangeSelection((e=>this.onListSelection(e)))),this._allMenuItems=i,this._list.splice(0,this._list.length,this._allMenuItems),this._list.length&&this.focusNext()}focusCondition(e){return!e.disabled&&"action"===e.kind}hide(e){this._delegate.onHide(e),this.cts.cancel(),this._contextViewService.hideContextView()}layout(e){const t=this._allMenuItems.filter((e=>"header"===e.kind)).length,i=this._allMenuItems.length*this._actionLineHeight+t*this._headerLineHeight-t*this._actionLineHeight;this._list.layout(i);let s=e;if(this._allMenuItems.length>=50)s=380;else{const t=this._allMenuItems.map(((e,t)=>{const i=this.domNode.ownerDocument.getElementById(this._list.getElementID(t));if(i){i.style.width="auto";const e=i.getBoundingClientRect().width;return i.style.width="",e}return 0}));s=Math.max(...t,e)}const n=Math.min(i,.7*this.domNode.ownerDocument.body.clientHeight);return this._list.layout(n,s),this.domNode.style.height=`${n}px`,this._list.domFocus(),s}focusPrevious(){this._list.focusPrevious(1,!0,void 0,this.focusCondition)}focusNext(){this._list.focusNext(1,!0,void 0,this.focusCondition)}acceptSelected(e){const t=this._list.getFocus();if(0===t.length)return;const i=t[0],s=this._list.element(i);if(!this.focusCondition(s))return;const n=e?new W:new B;this._list.setSelection([i],n)}onListSelection(e){if(!e.elements.length)return;const t=e.elements[0];t.item&&this.focusCondition(t)?this._delegate.onSelect(t.item,e.browserEvent instanceof W):this._list.setSelection([])}onFocus(){const e=this._list.getFocus();if(0===e.length)return;const t=e[0],i=this._list.element(t);this._delegate.onFocus?.(i.item)}async onListHover(e){const t=e.element;if(t&&t.item&&this.focusCondition(t)){if(this._delegate.onHover&&!t.disabled&&"action"===t.kind){const e=await this._delegate.onHover(t.item,this.cts.token);t.canPreview=e?e.canPreview:void 0}e.index&&this._list.splice(e.index,1,[t])}this._list.setFocus("number"===typeof e.index?[e.index]:[])}onListClick(e){e.element&&this.focusCondition(e.element)&&this._list.setFocus([])}};function G(e){return e.replace(/\r\n|\r|\n/g," ")}z=D([M(4,N.l),M(5,m.b)],z);var j=i(27195),K=i(32848),Y=i(14718),q=i(63591),$=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Q=function(e,t){return function(i,s){t(i,s,e)}};(0,O.x1A)("actionBar.toggledBackground",O.c1f,(0,b.kg)("actionBar.toggledBackground","Background color for toggled action items in action bar."));const X={Visible:new K.N1("codeActionMenuVisible",!1,(0,b.kg)("codeActionMenuVisible","Whether the action widget list is visible"))},Z=(0,q.u1)("actionWidgetService");let J=class extends l.jG{get isVisible(){return X.Visible.getValue(this._contextKeyService)||!1}constructor(e,t,i){super(),this._contextViewService=e,this._contextKeyService=t,this._instantiationService=i,this._list=this._register(new l.HE)}show(e,t,i,s,n,r,o){const a=X.Visible.bindTo(this._contextKeyService),l=this._instantiationService.createInstance(z,e,t,i,s);this._contextViewService.showContextView({getAnchor:()=>n,render:e=>(a.set(!0),this._renderWidget(e,l,o??[])),onHide:e=>{a.reset(),this._onWidgetClosed(e)}},r,!1)}acceptSelected(e){this._list.value?.acceptSelected(e)}focusPrevious(){this._list?.value?.focusPrevious()}focusNext(){this._list?.value?.focusNext()}hide(e){this._list.value?.hide(e),this._list.clear()}_renderWidget(e,t,i){const s=document.createElement("div");if(s.classList.add("action-widget"),e.appendChild(s),this._list.value=t,!this._list.value)throw new Error("List has no value");s.appendChild(this._list.value.domNode);const r=new l.Cm,o=document.createElement("div"),a=e.appendChild(o);a.classList.add("context-view-block"),r.add(n.ko(a,n.Bx.MOUSE_DOWN,(e=>e.stopPropagation())));const c=document.createElement("div"),h=e.appendChild(c);h.classList.add("context-view-pointerBlock"),r.add(n.ko(h,n.Bx.POINTER_MOVE,(()=>h.remove()))),r.add(n.ko(h,n.Bx.MOUSE_DOWN,(()=>h.remove())));let d=0;if(i.length){const e=this._createActionBar(".action-widget-action-bar",i);e&&(s.appendChild(e.getContainer().parentElement),r.add(e),d=e.getContainer().offsetWidth)}const u=this._list.value?.layout(d);s.style.width=`${u}px`;const g=r.add(n.w5(e));return r.add(g.onDidBlur((()=>this.hide(!0)))),r}_createActionBar(e,t){if(!t.length)return;const i=n.$(e),s=new L.E(i);return s.push(t,{icon:!1,label:!0}),s}_onWidgetClosed(e){this._list.value?.hide(e)}};J=$([Q(0,N.l),Q(1,K.fN),Q(2,q._Y)],J),(0,Y.v)(Z,J,1);const ee=1100;(0,j.ug)(class extends j.L{constructor(){super({id:"hideCodeActionWidget",title:(0,b.aS)("hideCodeActionWidget.title","Hide action widget"),precondition:X.Visible,keybinding:{weight:ee,primary:9,secondary:[1033]}})}run(e){e.get(Z).hide(!0)}}),(0,j.ug)(class extends j.L{constructor(){super({id:"selectPrevCodeAction",title:(0,b.aS)("selectPrevCodeAction.title","Select previous action"),precondition:X.Visible,keybinding:{weight:ee,primary:16,secondary:[2064],mac:{primary:16,secondary:[2064,302]}}})}run(e){const t=e.get(Z);t instanceof J&&t.focusPrevious()}}),(0,j.ug)(class extends j.L{constructor(){super({id:"selectNextCodeAction",title:(0,b.aS)("selectNextCodeAction.title","Select next action"),precondition:X.Visible,keybinding:{weight:ee,primary:18,secondary:[2066],mac:{primary:18,secondary:[2066,300]}}})}run(e){const t=e.get(Z);t instanceof J&&t.focusNext()}}),(0,j.ug)(class extends j.L{constructor(){super({id:P,title:(0,b.aS)("acceptSelected.title","Accept selected action"),precondition:X.Visible,keybinding:{weight:ee,primary:3,secondary:[2137]}})}run(e){const t=e.get(Z);t instanceof J&&t.acceptSelected()}}),(0,j.ug)(class extends j.L{constructor(){super({id:F,title:(0,b.aS)("previewSelected.title","Preview selected action"),precondition:X.Visible,keybinding:{weight:ee,primary:2051}})}run(e){const t=e.get(Z);t instanceof J&&t.acceptSelected(!0)}});var te,ie=i(50091),se=i(84001),ne=i(75147),re=i(73823),oe=i(86723),ae=i(47612),le=i(59473),ce=i(90651),he=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},de=function(e,t){return function(i,s){t(i,s,e)}};let ue=class extends l.jG{static{te=this}static{this.ID="editor.contrib.codeActionController"}static get(e){return e.getContribution(te.ID)}constructor(e,t,i,s,n,r,o,c,h,d,u){super(),this._commandService=o,this._configurationService=c,this._actionWidgetService=h,this._instantiationService=d,this._telemetryService=u,this._activeCodeActions=this._register(new l.HE),this._showDisabled=!1,this._disposed=!1,this._editor=e,this._model=this._register(new le.Dc(this._editor,n.codeActionProvider,t,i,r,c,this._telemetryService)),this._register(this._model.onDidChangeState((e=>this.update(e)))),this._lightBulbWidget=new a.d((()=>{const e=this._editor.getContribution(y.E.ID);return e&&this._register(e.onClick((e=>this.showCodeActionsFromLightbulb(e.actions,e)))),e})),this._resolver=s.createInstance(v),this._register(this._editor.onDidLayoutChange((()=>this._actionWidgetService.hide())))}dispose(){this._disposed=!0,super.dispose()}async showCodeActionsFromLightbulb(e,t){if(e.allAIFixes&&1===e.validActions.length){const t=e.validActions[0],i=t.action.command;return i&&"inlineChat.start"===i.id&&i.arguments&&i.arguments.length>=1&&(i.arguments[0]={...i.arguments[0],autoSend:!1}),void await this._applyCodeAction(t,!1,!1,u.Qp.FromAILightbulb)}await this.showCodeActionList(e,t,{includeDisabledActions:!1,fromLightbulb:!0})}showCodeActions(e,t,i){return this.showCodeActionList(t,i,{includeDisabledActions:!1,fromLightbulb:!1})}manualTriggerAtCurrentPosition(e,t,i,s){if(!this._editor.hasModel())return;w.k.get(this._editor)?.closeMessage();const n=this._editor.getPosition();this._trigger({type:1,triggerAction:t,filter:i,autoApply:s,context:{notAvailableMessage:e,position:n}})}_trigger(e){return this._model.trigger(e)}async _applyCodeAction(e,t,i,s){try{await this._instantiationService.invokeFunction(u.W4,e,s,{preview:i,editor:this._editor})}finally{t&&this._trigger({type:2,triggerAction:p.fo.QuickFix,filter:{}})}}hideLightBulbWidget(){this._lightBulbWidget.rawValue?.hide(),this._lightBulbWidget.rawValue?.gutterHide()}async update(e){if(1!==e.type)return void this.hideLightBulbWidget();let t;try{t=await e.actions}catch(s){return void(0,o.dz)(s)}if(this._disposed)return;const i=this._editor.getSelection();if(i?.startLineNumber===e.position.lineNumber)if(this._lightBulbWidget.value?.update(t,e.trigger,e.position),1===e.trigger.type){if(e.trigger.filter?.include){const i=this.tryGetValidActionToApply(e.trigger,t);if(i){try{this.hideLightBulbWidget(),await this._applyCodeAction(i,!1,!1,u.Qp.FromCodeActions)}finally{t.dispose()}return}if(e.trigger.context){const i=this.getInvalidActionThatWouldHaveBeenApplied(e.trigger,t);if(i&&i.action.disabled)return w.k.get(this._editor)?.showMessage(i.action.disabled,e.trigger.context.position),void t.dispose()}}const i=!!e.trigger.filter?.include;if(e.trigger.context&&(!t.allActions.length||!i&&!t.validActions.length))return w.k.get(this._editor)?.showMessage(e.trigger.context.notAvailableMessage,e.trigger.context.position),this._activeCodeActions.value=t,void t.dispose();this._activeCodeActions.value=t,this.showCodeActionList(t,this.toCoords(e.position),{includeDisabledActions:i,fromLightbulb:!1})}else this._actionWidgetService.isVisible?t.dispose():this._activeCodeActions.value=t}getInvalidActionThatWouldHaveBeenApplied(e,t){if(t.allActions.length)return"first"===e.autoApply&&0===t.validActions.length||"ifSingle"===e.autoApply&&1===t.allActions.length?t.allActions.find((({action:e})=>e.disabled)):void 0}tryGetValidActionToApply(e,t){if(t.validActions.length)return"first"===e.autoApply&&t.validActions.length>0||"ifSingle"===e.autoApply&&1===t.validActions.length?t.validActions[0]:void 0}static{this.DECORATION=h.kI.register({description:"quickfix-highlight",className:"quickfix-edit-highlight"})}async showCodeActionList(e,t,i){const s=this._editor.createDecorationsCollection(),n=this._editor.getDomNode();if(!n)return;const o=i.includeDisabledActions&&(this._showDisabled||0===e.validActions.length)?e.allActions:e.validActions;if(!o.length)return;const a=c.y.isIPosition(t)?this.toCoords(t):t,l={onSelect:async(e,t)=>{this._applyCodeAction(e,!0,!!t,i.fromLightbulb?u.Qp.FromAILightbulb:u.Qp.FromCodeActions),this._actionWidgetService.hide(!1),s.clear()},onHide:e=>{this._editor?.focus(),s.clear()},onHover:async(e,t)=>{if(t.isCancellationRequested)return;let i=!1;const s=e.action.kind;if(s){const e=new g.k(s);i=[p.gB.RefactorExtract,p.gB.RefactorInline,p.gB.RefactorRewrite,p.gB.RefactorMove,p.gB.Source].some((t=>t.contains(e)))}return{canPreview:i||!!e.action.edit?.edits.length}},onFocus:e=>{if(e&&e.action){const t=e.action.ranges,i=e.action.diagnostics;if(s.clear(),t&&t.length>0){const e=i&&i?.length>1?i.map((e=>({range:e,options:te.DECORATION}))):t.map((e=>({range:e,options:te.DECORATION})));s.set(e)}else if(i&&i.length>0){const e=i.map((e=>({range:e,options:te.DECORATION})));s.set(e);const t=i[0];if(t.startLineNumber&&t.startColumn){const e=this._editor.getModel()?.getWordAtPosition({lineNumber:t.startLineNumber,column:t.startColumn})?.word;r.h5((0,b.kg)("editingNewSelection","Context: {0} at line {1} and column {2}.",e,t.startLineNumber,t.startColumn))}}}else s.clear()}};this._actionWidgetService.show("codeActionWidget",!0,function(e,t,i){if(!t)return e.map((e=>({kind:"action",item:e,group:E,disabled:!!e.action.disabled,label:e.action.disabled||e.action.title,canPreview:!!e.action.edit?.edits.length})));const s=S.map((e=>({group:e,actions:[]})));for(const r of e){const e=r.action.kind?new g.k(r.action.kind):g.k.None;for(const t of s)if(t.group.kind.contains(e)){t.actions.push(r);break}}const n=[];for(const r of s)if(r.actions.length){n.push({kind:"header",group:r.group});for(const e of r.actions){const t=r.group;n.push({kind:"action",item:e,group:e.action.isAI?{title:t.title,kind:t.kind,icon:C.W.sparkle}:t,label:e.action.title,disabled:!!e.action.disabled,keybinding:i(e.action)})}}return n}(o,this._shouldShowHeaders(),this._resolver.getResolver()),l,a,n,this._getActionBarActions(e,t,i))}toCoords(e){if(!this._editor.hasModel())return{x:0,y:0};this._editor.revealPosition(e,1),this._editor.render();const t=this._editor.getScrolledVisiblePosition(e),i=(0,n.BK)(this._editor.getDomNode());return{x:i.left+t.left,y:i.top+t.top+t.height}}_shouldShowHeaders(){const e=this._editor?.getModel();return this._configurationService.getValue("editor.codeActionWidget.showHeaders",{resource:e?.uri})}_getActionBarActions(e,t,i){if(i.fromLightbulb)return[];const s=e.documentation.map((e=>({id:e.id,label:e.title,tooltip:e.tooltip??"",class:void 0,enabled:!0,run:()=>this._commandService.executeCommand(e.id,...e.arguments??[])})));return i.includeDisabledActions&&e.validActions.length>0&&e.allActions.length!==e.validActions.length&&s.push(this._showDisabled?{id:"hideMoreActions",label:(0,b.kg)("hideMoreActions","Hide Disabled"),enabled:!0,tooltip:"",class:void 0,run:()=>(this._showDisabled=!1,this.showCodeActionList(e,t,i))}:{id:"showMoreActions",label:(0,b.kg)("showMoreActions","Show Disabled"),enabled:!0,tooltip:"",class:void 0,run:()=>(this._showDisabled=!0,this.showCodeActionList(e,t,i))}),s}};ue=te=he([de(1,ne.DR),de(2,K.fN),de(3,q._Y),de(4,d.ILanguageFeaturesService),de(5,re.N8),de(6,ie.d),de(7,se.pG),de(8,Z),de(9,q._Y),de(10,ce.k)],ue),(0,ae.zy)(((e,t)=>{var i,s;i=".quickfix-edit-highlight",(s=e.getColor(O.Ubg))&&t.addRule(`.monaco-editor ${i} { background-color: ${s}; }`);const n=e.getColor(O.ECk);n&&t.addRule(`.monaco-editor .quickfix-edit-highlight { border: 1px ${(0,oe.Bb)(e.type)?"dotted":"solid"} ${n}; box-sizing: border-box; }`)}))},59473:(e,t,i)=>{"use strict";i.d(t,{D_:()=>_,Dc:()=>S});var s=i(90766),n=i(64383),r=i(41234),o=i(5662),a=i(89403),l=i(87908),c=i(83069),h=i(75326),d=i(32848),u=i(73823),g=i(61407),p=i(55130),m=i(8995),f=i(78381);const _=new d.N1("supportedCodeAction",""),v="_typescript.applyFixAllCodeAction";class C extends o.jG{constructor(e,t,i,n=250){super(),this._editor=e,this._markerService=t,this._signalChange=i,this._delay=n,this._autoTriggerTimer=this._register(new s.pc),this._register(this._markerService.onMarkerChanged((e=>this._onMarkerChanges(e)))),this._register(this._editor.onDidChangeCursorPosition((()=>this._tryAutoTrigger())))}trigger(e){const t=this._getRangeOfSelectionUnlessWhitespaceEnclosed(e);this._signalChange(t?{trigger:e,selection:t}:void 0)}_onMarkerChanges(e){const t=this._editor.getModel();t&&e.some((e=>(0,a.n4)(e,t.uri)))&&this._tryAutoTrigger()}_tryAutoTrigger(){this._autoTriggerTimer.cancelAndSet((()=>{this.trigger({type:2,triggerAction:g.fo.Default})}),this._delay)}_getRangeOfSelectionUnlessWhitespaceEnclosed(e){if(!this._editor.hasModel())return;const t=this._editor.getSelection();if(1===e.type)return t;const i=this._editor.getOption(65).enabled;if(i!==l.jT.Off){if(i===l.jT.On)return t;if(i===l.jT.OnCode){if(!t.isEmpty())return t;const e=this._editor.getModel(),{lineNumber:i,column:s}=t.getPosition(),n=e.getLineContent(i);if(0===n.length)return;if(1===s){if(/\s/.test(n[0]))return}else if(s===e.getLineMaxColumn(i)){if(/\s/.test(n[n.length-1]))return}else if(/\s/.test(n[s-2])&&/\s/.test(n[s-1]))return}return t}}}var b;!function(e){e.Empty={type:0};e.Triggered=class{constructor(e,t,i){this.trigger=e,this.position=t,this._cancellablePromise=i,this.type=1,this.actions=i.catch((e=>{if((0,n.MB)(e))return E;throw e}))}cancel(){this._cancellablePromise.cancel()}}}(b||(b={}));const E=Object.freeze({allActions:[],validActions:[],dispose:()=>{},documentation:[],hasAutoFix:!1,hasAIFix:!1,allAIFixes:!1});class S extends o.jG{constructor(e,t,i,s,n,a,l){super(),this._editor=e,this._registry=t,this._markerService=i,this._progressService=n,this._configurationService=a,this._telemetryService=l,this._codeActionOracle=this._register(new o.HE),this._state=b.Empty,this._onDidChangeState=this._register(new r.vl),this.onDidChangeState=this._onDidChangeState.event,this._disposed=!1,this._supportedCodeActions=_.bindTo(s),this._register(this._editor.onDidChangeModel((()=>this._update()))),this._register(this._editor.onDidChangeModelLanguage((()=>this._update()))),this._register(this._registry.onDidChange((()=>this._update()))),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(65)&&this._update()}))),this._update()}dispose(){this._disposed||(this._disposed=!0,super.dispose(),this.setState(b.Empty,!0))}_settingEnabledNearbyQuickfixes(){const e=this._editor?.getModel();return!!this._configurationService&&this._configurationService.getValue("editor.codeActionWidget.includeNearbyQuickFixes",{resource:e?.uri})}_update(){if(this._disposed)return;this._codeActionOracle.value=void 0,this.setState(b.Empty);const e=this._editor.getModel();if(e&&this._registry.has(e)&&!this._editor.getOption(92)){const t=this._registry.all(e).flatMap((e=>e.providedCodeActionKinds??[]));this._supportedCodeActions.set(t.join(" ")),this._codeActionOracle.value=new C(this._editor,this._markerService,(t=>{if(!t)return void this.setState(b.Empty);const i=t.selection.getStartPosition(),n=(0,s.SS)((async i=>{if(this._settingEnabledNearbyQuickfixes()&&1===t.trigger.type&&(t.trigger.triggerAction===g.fo.QuickFix||t.trigger.filter?.include?.contains(g.gB.QuickFix))){const s=await(0,p.dU)(this._registry,e,t.selection,t.trigger,u.ke.None,i),n=[...s.allActions];if(i.isCancellationRequested)return E;const r=s.validActions?.some((e=>!!e.action.kind&&g.gB.QuickFix.contains(new m.k(e.action.kind)))),o=this._markerService.read({resource:e.uri});if(r){for(const e of s.validActions)e.action.command?.arguments?.some((e=>"string"===typeof e&&e.includes(v)))&&(e.action.diagnostics=[...o.filter((e=>e.relatedInformation))]);return{validActions:s.validActions,allActions:n,documentation:s.documentation,hasAutoFix:s.hasAutoFix,hasAIFix:s.hasAIFix,allAIFixes:s.allAIFixes,dispose:()=>{s.dispose()}}}if(!r&&o.length>0){const r=t.selection.getPosition();let a=r,l=Number.MAX_VALUE;const d=[...s.validActions];for(const f of o){const m=f.endColumn,_=f.endLineNumber,C=f.startLineNumber;if(_===r.lineNumber||C===r.lineNumber){a=new c.y(_,m);const f={type:t.trigger.type,triggerAction:t.trigger.triggerAction,filter:{include:t.trigger.filter?.include?t.trigger.filter?.include:g.gB.QuickFix},autoApply:t.trigger.autoApply,context:{notAvailableMessage:t.trigger.context?.notAvailableMessage||"",position:a}},C=new h.L(a.lineNumber,a.column,a.lineNumber,a.column),b=await(0,p.dU)(this._registry,e,C,f,u.ke.None,i);if(0!==b.validActions.length){for(const e of b.validActions)e.action.command?.arguments?.some((e=>"string"===typeof e&&e.includes(v)))&&(e.action.diagnostics=[...o.filter((e=>e.relatedInformation))]);0===s.allActions.length&&n.push(...b.allActions),Math.abs(r.column-m)i.findIndex((t=>t.action.title===e.action.title))===t));return m.sort(((e,t)=>e.action.isPreferred&&!t.action.isPreferred?-1:!e.action.isPreferred&&t.action.isPreferred||e.action.isAI&&!t.action.isAI?1:!e.action.isAI&&t.action.isAI?-1:0)),{validActions:m,allActions:n,documentation:s.documentation,hasAutoFix:s.hasAutoFix,hasAIFix:s.hasAIFix,allAIFixes:s.allAIFixes,dispose:()=>{s.dispose()}}}}if(1===t.trigger.type){const s=new f.W,n=await(0,p.dU)(this._registry,e,t.selection,t.trigger,u.ke.None,i);return this._telemetryService&&this._telemetryService.publicLog2("codeAction.invokedDurations",{codeActions:n.validActions.length,duration:s.elapsed()}),n}return(0,p.dU)(this._registry,e,t.selection,t.trigger,u.ke.None,i)}));1===t.trigger.type&&this._progressService?.showWhile(n,250);const r=new b.Triggered(t.trigger,i,n);let o=!1;1===this._state.type&&(o=1===this._state.trigger.type&&1===r.type&&2===r.trigger.type&&this._state.position!==r.position),o?setTimeout((()=>{this.setState(r)}),500):this.setState(r)}),void 0),this._codeActionOracle.value.trigger({type:2,triggerAction:g.fo.Default})}else this._supportedCodeActions.reset()}trigger(e){this._codeActionOracle.value?.trigger(e)}setState(e,t){e!==this._state&&(1===this._state.type&&this._state.cancel(),this._state=e,t||this._disposed||this._onDidChangeState.fire(e))}}},96758:(e,t,i)=>{"use strict";i.d(t,{E:()=>R});var s,n=i(8597),r=i(25154),o=i(10350),a=i(41234),l=i(5662),c=i(25689),h=i(16223),d=i(87289),u=i(78049),g=i(55130),p=i(78209),m=i(98031),f=i(61394),_=i(36677),v=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},C=function(e,t){return function(i,s){t(i,s,e)}};const b=(0,f.pU)("gutter-lightbulb",o.W.lightBulb,p.kg("gutterLightbulbWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor.")),E=(0,f.pU)("gutter-lightbulb-auto-fix",o.W.lightbulbAutofix,p.kg("gutterLightbulbAutoFixWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and a quick fix is available.")),S=(0,f.pU)("gutter-lightbulb-sparkle",o.W.lightbulbSparkle,p.kg("gutterLightbulbAIFixWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and an AI fix is available.")),y=(0,f.pU)("gutter-lightbulb-aifix-auto-fix",o.W.lightbulbSparkleAutofix,p.kg("gutterLightbulbAIFixAutoFixWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and an AI fix and a quick fix is available.")),w=(0,f.pU)("gutter-lightbulb-sparkle-filled",o.W.sparkleFilled,p.kg("gutterLightbulbSparkleFilledWidget","Icon which spawns code actions menu from the gutter when there is no space in the editor and an AI fix and a quick fix is available."));var L;!function(e){e.Hidden={type:0};e.Showing=class{constructor(e,t,i,s){this.actions=e,this.trigger=t,this.editorPosition=i,this.widgetPosition=s,this.type=1}}}(L||(L={}));let R=class extends l.jG{static{s=this}static{this.GUTTER_DECORATION=d.kI.register({description:"codicon-gutter-lightbulb-decoration",glyphMarginClassName:c.L.asClassName(o.W.lightBulb),glyphMargin:{position:h.ZS.Left},stickiness:1})}static{this.ID="editor.contrib.lightbulbWidget"}static{this._posPref=[0]}constructor(e,t){super(),this._editor=e,this._keybindingService=t,this._onClick=this._register(new a.vl),this.onClick=this._onClick.event,this._state=L.Hidden,this._gutterState=L.Hidden,this._iconClasses=[],this.lightbulbClasses=["codicon-"+b.id,"codicon-"+y.id,"codicon-"+E.id,"codicon-"+S.id,"codicon-"+w.id],this.gutterDecoration=s.GUTTER_DECORATION,this._domNode=n.$("div.lightBulbWidget"),this._domNode.role="listbox",this._register(r.q.ignoreTarget(this._domNode)),this._editor.addContentWidget(this),this._register(this._editor.onDidChangeModelContent((e=>{const t=this._editor.getModel();(1!==this.state.type||!t||this.state.editorPosition.lineNumber>=t.getLineCount())&&this.hide(),(1!==this.gutterState.type||!t||this.gutterState.editorPosition.lineNumber>=t.getLineCount())&&this.gutterHide()}))),this._register(n.Xc(this._domNode,(e=>{if(1!==this.state.type)return;this._editor.focus(),e.preventDefault();const{top:t,height:i}=n.BK(this._domNode),s=this._editor.getOption(67);let r=Math.floor(s/3);null!==this.state.widgetPosition.position&&this.state.widgetPosition.position.lineNumber{1===(1&e.buttons)&&this.hide()}))),this._register(a.Jh.runAndSubscribe(this._keybindingService.onDidUpdateKeybindings,(()=>{this._preferredKbLabel=this._keybindingService.lookupKeybinding(g.pR)?.getLabel()??void 0,this._quickFixKbLabel=this._keybindingService.lookupKeybinding(g.pQ)?.getLabel()??void 0,this._updateLightBulbTitleAndIcon()}))),this._register(this._editor.onMouseDown((async e=>{if(!e.target.element||!this.lightbulbClasses.some((t=>e.target.element&&e.target.element.classList.contains(t))))return;if(1!==this.gutterState.type)return;this._editor.focus();const{top:t,height:i}=n.BK(e.target.element),s=this._editor.getOption(67);let r=Math.floor(s/3);null!==this.gutterState.widgetPosition.position&&this.gutterState.widgetPosition.position.lineNumber22,g=e=>e>2&&this._editor.getTopForLineNumber(e)===this._editor.getTopForLineNumber(e-1),p=this._editor.getLineDecorations(r);let m=!1;if(p)for(const s of p){const e=s.options.glyphMarginClassName;if(e&&!this.lightbulbClasses.some((t=>e.includes(t)))){m=!0;break}}let f=r,_=1;if(!d){const a=e=>{const t=n.getLineContent(e);return/^\s*$|^\s+/.test(t)||t.length<=_};if(r>1&&!g(r-1)){const o=r===n.getLineCount(),l=r>1&&a(r-1),c=!o&&a(r+1),h=a(r),d=!c&&!l;if(!(c||l||m))return this.gutterState=new L.Showing(e,t,i,{position:{lineNumber:f,column:_},preference:s._posPref}),this.renderGutterLightbub(),this.hide();l||o||l&&!h?f-=1:(c||d&&h)&&(f+=1)}else if(1!==r||r!==n.getLineCount()&&(a(r+1)||a(r))){if(r{this._gutterDecorationID=t.addDecoration(new _.Q(e,0,e,0),this.gutterDecoration)}))}_removeGutterDecoration(e){this._editor.changeDecorations((t=>{t.removeDecoration(e),this._gutterDecorationID=void 0}))}_updateGutterDecoration(e,t){this._editor.changeDecorations((i=>{i.changeDecoration(e,new _.Q(t,0,t,0)),i.changeDecorationOptions(e,this.gutterDecoration)}))}_updateLightbulbTitle(e,t){1===this.state.type&&(t?this.title=p.kg("codeActionAutoRun","Run: {0}",this.state.actions.validActions[0].action.title):e&&this._preferredKbLabel?this.title=p.kg("preferredcodeActionWithKb","Show Code Actions. Preferred Quick Fix Available ({0})",this._preferredKbLabel):!e&&this._quickFixKbLabel?this.title=p.kg("codeActionWithKb","Show Code Actions ({0})",this._quickFixKbLabel):e||(this.title=p.kg("codeAction","Show Code Actions")))}set title(e){this._domNode.title=e}};R=s=v([C(1,m.b)],R)},61407:(e,t,i)=>{"use strict";i.d(t,{QA:()=>h,Vi:()=>d,aF:()=>l,fo:()=>o,gB:()=>r,uJ:()=>a});var s=i(64383),n=i(8995);const r=new class{constructor(){this.QuickFix=new n.k("quickfix"),this.Refactor=new n.k("refactor"),this.RefactorExtract=this.Refactor.append("extract"),this.RefactorInline=this.Refactor.append("inline"),this.RefactorMove=this.Refactor.append("move"),this.RefactorRewrite=this.Refactor.append("rewrite"),this.Notebook=new n.k("notebook"),this.Source=new n.k("source"),this.SourceOrganizeImports=this.Source.append("organizeImports"),this.SourceFixAll=this.Source.append("fixAll"),this.SurroundWith=this.Refactor.append("surround")}};var o;function a(e,t){return!(e.include&&!e.include.intersects(t))&&((!e.excludes||!e.excludes.some((i=>c(t,i,e.include))))&&!(!e.includeSourceActions&&r.Source.contains(t)))}function l(e,t){const i=t.kind?new n.k(t.kind):void 0;return!!(!e.include||i&&e.include.contains(i))&&(!(e.excludes&&i&&e.excludes.some((t=>c(i,t,e.include))))&&(!(!e.includeSourceActions&&i&&r.Source.contains(i))&&!(e.onlyIncludePreferredActions&&!t.isPreferred)))}function c(e,t,i){return!!t.contains(e)&&(!i||!t.contains(i))}!function(e){e.Refactor="refactor",e.RefactorPreview="refactor preview",e.Lightbulb="lightbulb",e.Default="other (default)",e.SourceAction="source action",e.QuickFix="quick fix action",e.FixAll="fix all",e.OrganizeImports="organize imports",e.AutoFix="auto fix",e.QuickFixHover="quick fix hover window",e.OnSave="save participants",e.ProblemsView="problems view"}(o||(o={}));class h{static fromUser(e,t){return e&&"object"===typeof e?new h(h.getKindFromUser(e,t.kind),h.getApplyFromUser(e,t.apply),h.getPreferredUser(e)):new h(t.kind,t.apply,!1)}static getApplyFromUser(e,t){switch("string"===typeof e.apply?e.apply.toLowerCase():""){case"first":return"first";case"never":return"never";case"ifsingle":return"ifSingle";default:return t}}static getKindFromUser(e,t){return"string"===typeof e.kind?new n.k(e.kind):t}static getPreferredUser(e){return"boolean"===typeof e.preferred&&e.preferred}constructor(e,t,i){this.kind=e,this.apply=t,this.preferred=i}}class d{constructor(e,t,i){this.action=e,this.provider=t,this.highlightRange=i}async resolve(e){if(this.provider?.resolveCodeAction&&!this.action.edit){let i;try{i=await this.provider.resolveCodeAction(this.action,e)}catch(t){(0,s.M_)(t)}i&&(this.action.edit=i.edit)}return this}}},64215:(e,t,i)=>{"use strict";var s=i(90766),n=i(64383),r=i(5662),o=i(55190),a=i(31450),l=i(87908),c=i(60002),h=i(18447),d=i(631),u=i(79400),g=i(23750),p=i(50091),m=i(56942);class f{constructor(){this.lenses=[],this._disposables=new r.Cm}dispose(){this._disposables.dispose()}get isDisposed(){return this._disposables.isDisposed}add(e,t){this._disposables.add(e);for(const i of e.lenses)this.lenses.push({symbol:i,provider:t})}}async function _(e,t,i){const s=e.ordered(t),r=new Map,o=new f,a=s.map((async(e,s)=>{r.set(e,s);try{const s=await Promise.resolve(e.provideCodeLenses(t,i));s&&o.add(s,e)}catch(a){(0,n.M_)(a)}}));return await Promise.all(a),o.lenses=o.lenses.sort(((e,t)=>e.symbol.range.startLineNumbert.symbol.range.startLineNumber?1:r.get(e.provider)r.get(t.provider)?1:e.symbol.range.startColumnt.symbol.range.startColumn?1:0)),o}p.w.registerCommand("_executeCodeLensProvider",(function(e,...t){let[i,s]=t;(0,d.j)(u.r.isUri(i)),(0,d.j)("number"===typeof s||!s);const{codeLensProvider:o}=e.get(m.ILanguageFeaturesService),a=e.get(g.IModelService).getModel(i);if(!a)throw(0,n.Qg)();const l=[],c=new r.Cm;return _(o,a,h.XO.None).then((e=>{c.add(e);const t=[];for(const i of e.lenses)void 0===s||null===s||Boolean(i.symbol.command)?l.push(i.symbol):s-- >0&&i.provider.resolveCodeLens&&t.push(Promise.resolve(i.provider.resolveCodeLens(a,i.symbol,h.XO.None)).then((e=>l.push(e||i.symbol))));return Promise.all(t)})).then((()=>l)).finally((()=>{setTimeout((()=>c.dispose()),100)}))}));var v=i(41234),C=i(74320),b=i(36677),E=i(14718),S=i(63591),y=i(9711),w=i(25893),L=i(8597),R=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},T=function(e,t){return function(i,s){t(i,s,e)}};const x=(0,S.u1)("ICodeLensCache");class k{constructor(e,t){this.lineCount=e,this.data=t}}let A=class{constructor(e){this._fakeProvider=new class{provideCodeLenses(){throw new Error("not supported")}},this._cache=new C.qK(20,.75);(0,L.U3)(w.G,(()=>e.remove("codelens/cache",1)));const t="codelens/cache2",i=e.get(t,1,"{}");this._deserialize(i);const s=v.Jh.filter(e.onWillSaveState,(e=>e.reason===y.LP.SHUTDOWN));v.Jh.once(s)((i=>{e.store(t,this._serialize(),1,1)}))}put(e,t){const i=t.lenses.map((e=>({range:e.symbol.range,command:e.symbol.command&&{id:"",title:e.symbol.command?.title}}))),s=new f;s.add({lenses:i,dispose:()=>{}},this._fakeProvider);const n=new k(e.getLineCount(),s);this._cache.set(e.uri.toString(),n)}get(e){const t=this._cache.get(e.uri.toString());return t&&t.lineCount===e.getLineCount()?t.data:void 0}delete(e){this._cache.delete(e.uri.toString())}_serialize(){const e=Object.create(null);for(const[t,i]of this._cache){const s=new Set;for(const e of i.data.lenses)s.add(e.symbol.range.startLineNumber);e[t]={lineCount:i.lineCount,lines:[...s.values()]}}return JSON.stringify(e)}_deserialize(e){try{const t=JSON.parse(e);for(const e in t){const i=t[e],s=[];for(const e of i.lines)s.push({range:new b.Q(e,1,e,11)});const n=new f;n.add({lenses:s,dispose(){}},this._fakeProvider),this._cache.set(e,new k(i.lineCount,n))}}catch{}}};A=R([T(0,y.CS)],A),(0,E.v)(x,A,1);var N=i(20370),I=i(87289);class O{constructor(e,t,i){this.afterColumn=1073741824,this.afterLineNumber=e,this.heightInPx=t,this._onHeight=i,this.suppressMouseDown=!0,this.domNode=document.createElement("div")}onComputedHeight(e){void 0===this._lastHeight?this._lastHeight=e:this._lastHeight!==e&&(this._lastHeight=e,this._onHeight())}isVisible(){return 0!==this._lastHeight&&this.domNode.hasAttribute("monaco-visible-view-zone")}}class D{static{this._idPool=0}constructor(e,t){this.allowEditorOverflow=!1,this.suppressMouseDown=!0,this._commands=new Map,this._isEmpty=!0,this._editor=e,this._id="codelens.widget-"+D._idPool++,this.updatePosition(t),this._domNode=document.createElement("span"),this._domNode.className="codelens-decoration"}withCommands(e,t){this._commands.clear();const i=[];let s=!1;for(let n=0;n{e.symbol.command&&a.push(e.symbol),i.addDecoration({range:e.symbol.range,options:P},(e=>this._decorationIds[t]=e)),o=o?b.Q.plusRange(o,e.symbol.range):b.Q.lift(e.symbol.range)})),this._viewZone=new O(o.startLineNumber-1,n,r),this._viewZoneId=s.addZone(this._viewZone),a.length>0&&(this._createContentWidgetIfNecessary(),this._contentWidget.withCommands(a,!1))}_createContentWidgetIfNecessary(){this._contentWidget?this._editor.layoutContentWidget(this._contentWidget):(this._contentWidget=new D(this._editor,this._viewZone.afterLineNumber+1),this._editor.addContentWidget(this._contentWidget))}dispose(e,t){this._decorationIds.forEach(e.removeDecoration,e),this._decorationIds=[],t?.removeZone(this._viewZoneId),this._contentWidget&&(this._editor.removeContentWidget(this._contentWidget),this._contentWidget=void 0),this._isDisposed=!0}isDisposed(){return this._isDisposed}isValid(){return this._decorationIds.some(((e,t)=>{const i=this._editor.getModel().getDecorationRange(e),s=this._data[t].symbol;return!(!i||b.Q.isEmpty(s.range)!==i.isEmpty())}))}updateCodeLensSymbols(e,t){this._decorationIds.forEach(t.removeDecoration,t),this._decorationIds=[],this._data=e,this._data.forEach(((e,i)=>{t.addDecoration({range:e.symbol.range,options:P},(e=>this._decorationIds[i]=e))}))}updateHeight(e,t){this._viewZone.heightInPx=e,t.layoutZone(this._viewZoneId),this._contentWidget&&this._editor.layoutContentWidget(this._contentWidget)}computeIfNecessary(e){if(!this._viewZone.isVisible())return null;for(let t=0;t=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};let G=class{static{this.ID="css.editor.codeLens"}constructor(e,t,i,n,o,a){this._editor=e,this._languageFeaturesService=t,this._commandService=n,this._notificationService=o,this._codeLensCache=a,this._disposables=new r.Cm,this._localToDispose=new r.Cm,this._lenses=[],this._oldCodeLensModels=new r.Cm,this._provideCodeLensDebounce=i.for(t.codeLensProvider,"CodeLensProvide",{min:250}),this._resolveCodeLensesDebounce=i.for(t.codeLensProvider,"CodeLensResolve",{min:250,salt:"resolve"}),this._resolveCodeLensesScheduler=new s.uC((()=>this._resolveCodeLensesInViewport()),this._resolveCodeLensesDebounce.default()),this._disposables.add(this._editor.onDidChangeModel((()=>this._onModelChange()))),this._disposables.add(this._editor.onDidChangeModelLanguage((()=>this._onModelChange()))),this._disposables.add(this._editor.onDidChangeConfiguration((e=>{(e.hasChanged(50)||e.hasChanged(19)||e.hasChanged(18))&&this._updateLensStyle(),e.hasChanged(17)&&this._onModelChange()}))),this._disposables.add(t.codeLensProvider.onDidChange(this._onModelChange,this)),this._onModelChange(),this._updateLensStyle()}dispose(){this._localDispose(),this._disposables.dispose(),this._oldCodeLensModels.dispose(),this._currentCodeLensModel?.dispose()}_getLayoutInfo(){const e=Math.max(1.3,this._editor.getOption(67)/this._editor.getOption(52));let t=this._editor.getOption(19);return(!t||t<5)&&(t=.9*this._editor.getOption(52)|0),{fontSize:t,codeLensHeight:t*e|0}}_updateLensStyle(){const{codeLensHeight:e,fontSize:t}=this._getLayoutInfo(),i=this._editor.getOption(18),s=this._editor.getOption(50),{style:n}=this._editor.getContainerDomNode();n.setProperty("--vscode-editorCodeLens-lineHeight",`${e}px`),n.setProperty("--vscode-editorCodeLens-fontSize",`${t}px`),n.setProperty("--vscode-editorCodeLens-fontFeatureSettings",s.fontFeatureSettings),i&&(n.setProperty("--vscode-editorCodeLens-fontFamily",i),n.setProperty("--vscode-editorCodeLens-fontFamilyDefault",l.jU.fontFamily)),this._editor.changeViewZones((t=>{for(const i of this._lenses)i.updateHeight(e,t)}))}_localDispose(){this._getCodeLensModelPromise?.cancel(),this._getCodeLensModelPromise=void 0,this._resolveCodeLensesPromise?.cancel(),this._resolveCodeLensesPromise=void 0,this._localToDispose.clear(),this._oldCodeLensModels.clear(),this._currentCodeLensModel?.dispose()}_onModelChange(){this._localDispose();const e=this._editor.getModel();if(!e)return;if(!this._editor.getOption(17)||e.isTooLargeForTokenization())return;const t=this._codeLensCache.get(e);if(t&&this._renderCodeLensSymbols(t),!this._languageFeaturesService.codeLensProvider.has(e))return void(t&&(0,s.EQ)((()=>{const i=this._codeLensCache.get(e);t===i&&(this._codeLensCache.delete(e),this._onModelChange())}),3e4,this._localToDispose));for(const s of this._languageFeaturesService.codeLensProvider.all(e))if("function"===typeof s.onDidChange){const e=s.onDidChange((()=>i.schedule()));this._localToDispose.add(e)}const i=new s.uC((()=>{const t=Date.now();this._getCodeLensModelPromise?.cancel(),this._getCodeLensModelPromise=(0,s.SS)((t=>_(this._languageFeaturesService.codeLensProvider,e,t))),this._getCodeLensModelPromise.then((s=>{this._currentCodeLensModel&&this._oldCodeLensModels.add(this._currentCodeLensModel),this._currentCodeLensModel=s,this._codeLensCache.put(e,s);const n=this._provideCodeLensDebounce.update(e,Date.now()-t);i.delay=n,this._renderCodeLensSymbols(s),this._resolveCodeLensesInViewportSoon()}),n.dz)}),this._provideCodeLensDebounce.get(e));this._localToDispose.add(i),this._localToDispose.add((0,r.s)((()=>this._resolveCodeLensesScheduler.cancel()))),this._localToDispose.add(this._editor.onDidChangeModelContent((()=>{this._editor.changeDecorations((e=>{this._editor.changeViewZones((t=>{const i=[];let s=-1;this._lenses.forEach((e=>{e.isValid()&&s!==e.getLineNumber()?(e.update(t),s=e.getLineNumber()):i.push(e)}));const n=new M;i.forEach((e=>{e.dispose(n,t),this._lenses.splice(this._lenses.indexOf(e),1)})),n.commit(e)}))})),i.schedule(),this._resolveCodeLensesScheduler.cancel(),this._resolveCodeLensesPromise?.cancel(),this._resolveCodeLensesPromise=void 0}))),this._localToDispose.add(this._editor.onDidFocusEditorText((()=>{i.schedule()}))),this._localToDispose.add(this._editor.onDidBlurEditorText((()=>{i.cancel()}))),this._localToDispose.add(this._editor.onDidScrollChange((e=>{e.scrollTopChanged&&this._lenses.length>0&&this._resolveCodeLensesInViewportSoon()}))),this._localToDispose.add(this._editor.onDidLayoutChange((()=>{this._resolveCodeLensesInViewportSoon()}))),this._localToDispose.add((0,r.s)((()=>{if(this._editor.getModel()){const e=o.D.capture(this._editor);this._editor.changeDecorations((e=>{this._editor.changeViewZones((t=>{this._disposeAllLenses(e,t)}))})),e.restore(this._editor)}else this._disposeAllLenses(void 0,void 0)}))),this._localToDispose.add(this._editor.onMouseDown((e=>{if(9!==e.target.type)return;let t=e.target.element;if("SPAN"===t?.tagName&&(t=t.parentElement),"A"===t?.tagName)for(const i of this._lenses){const e=i.getCommand(t);if(e){this._commandService.executeCommand(e.id,...e.arguments||[]).catch((e=>this._notificationService.error(e)));break}}}))),i.schedule()}_disposeAllLenses(e,t){const i=new M;for(const s of this._lenses)s.dispose(i,t);e&&i.commit(e),this._lenses.length=0}_renderCodeLensSymbols(e){if(!this._editor.hasModel())return;const t=this._editor.getModel().getLineCount(),i=[];let s;for(const o of e.lenses){const e=o.symbol.range.startLineNumber;e<1||e>t||(s&&s[s.length-1].symbol.range.startLineNumber===e?s.push(o):(s=[o],i.push(s)))}if(!i.length&&!this._lenses.length)return;const n=o.D.capture(this._editor),r=this._getLayoutInfo();this._editor.changeDecorations((e=>{this._editor.changeViewZones((t=>{const s=new M;let n=0,o=0;for(;othis._resolveCodeLensesInViewportSoon()))),n++,o++)}for(;nthis._resolveCodeLensesInViewportSoon()))),o++;s.commit(e)}))})),n.restore(this._editor)}_resolveCodeLensesInViewportSoon(){this._editor.getModel()&&this._resolveCodeLensesScheduler.schedule()}_resolveCodeLensesInViewport(){this._resolveCodeLensesPromise?.cancel(),this._resolveCodeLensesPromise=void 0;const e=this._editor.getModel();if(!e)return;const t=[],i=[];if(this._lenses.forEach((s=>{const n=s.computeIfNecessary(e);n&&(t.push(n),i.push(s))})),0===t.length)return;const r=Date.now(),o=(0,s.SS)((s=>{const r=t.map(((t,r)=>{const o=new Array(t.length),a=t.map(((t,i)=>t.symbol.command||"function"!==typeof t.provider.resolveCodeLens?(o[i]=t.symbol,Promise.resolve(void 0)):Promise.resolve(t.provider.resolveCodeLens(e,t.symbol,s)).then((e=>{o[i]=e}),n.M_)));return Promise.all(a).then((()=>{s.isCancellationRequested||i[r].isDisposed()||i[r].updateCommands(o)}))}));return Promise.all(r)}));this._resolveCodeLensesPromise=o,this._resolveCodeLensesPromise.then((()=>{const t=this._resolveCodeLensesDebounce.update(e,Date.now()-r);this._resolveCodeLensesScheduler.delay=t,this._currentCodeLensModel&&this._codeLensCache.put(e,this._currentCodeLensModel),this._oldCodeLensModels.clear(),o===this._resolveCodeLensesPromise&&(this._resolveCodeLensesPromise=void 0)}),(e=>{(0,n.dz)(e),o===this._resolveCodeLensesPromise&&(this._resolveCodeLensesPromise=void 0)}))}async getModel(){return await this._getCodeLensModelPromise,await this._resolveCodeLensesPromise,this._currentCodeLensModel?.isDisposed?void 0:this._currentCodeLensModel}};G=V([z(1,m.ILanguageFeaturesService),z(2,W.ILanguageFeatureDebounceService),z(3,p.d),z(4,H.Ot),z(5,x)],G),(0,a.HW)(G.ID,G,1),(0,a.Fl)(class extends a.ks{constructor(){super({id:"codelens.showLensesInCurrentLine",precondition:c.R.hasCodeLensProvider,label:(0,U.kg)("showLensOnLine","Show CodeLens Commands For Current Line"),alias:"Show CodeLens Commands For Current Line"})}async run(e,t){if(!t.hasModel())return;const i=e.get(B.GK),s=e.get(p.d),n=e.get(H.Ot),r=t.getSelection().positionLineNumber,o=t.getContribution(G.ID);if(!o)return;const a=await o.getModel();if(!a)return;const l=[];for(const u of a.lenses)u.symbol.command&&u.symbol.range.startLineNumber===r&&l.push({label:u.symbol.command.title,command:u.symbol.command});if(0===l.length)return;const c=await i.pick(l,{canPickMany:!1,placeHolder:(0,U.kg)("placeHolder","Select a command")});if(!c)return;let h=c.command;if(a.isDisposed){const e=await o.getModel(),t=e?.lenses.find((e=>e.symbol.range.startLineNumber===r&&e.symbol.command?.title===h.title));if(!t||!t.symbol.command)return;h=t.symbol.command}try{await s.executeCommand(h.id,...h.arguments||[])}catch(d){n.error(d)}}})},68310:(e,t,i)=>{"use strict";i.d(t,{R:()=>g,j:()=>u});var s=i(18447),n=i(64383),r=i(79400),o=i(36677),a=i(23750),l=i(50091),c=i(56942),h=i(52363),d=i(84001);async function u(e,t,i,s=!0){return _(new p,e,t,i,s)}function g(e,t,i,s){return Promise.resolve(i.provideColorPresentations(e,t,s))}class p{constructor(){}async compute(e,t,i,s){const n=await e.provideDocumentColors(t,i);if(Array.isArray(n))for(const r of n)s.push({colorInfo:r,provider:e});return Array.isArray(n)}}class m{constructor(){}async compute(e,t,i,s){const n=await e.provideDocumentColors(t,i);if(Array.isArray(n))for(const r of n)s.push({range:r.range,color:[r.color.red,r.color.green,r.color.blue,r.color.alpha]});return Array.isArray(n)}}class f{constructor(e){this.colorInfo=e}async compute(e,t,i,n){const r=await e.provideColorPresentations(t,this.colorInfo,s.XO.None);return Array.isArray(r)&&n.push(...r),Array.isArray(r)}}async function _(e,t,i,s,r){let o,a=!1;const l=[],c=t.ordered(i);for(let u=c.length-1;u>=0;u--){const t=c[u];if(t instanceof h.L)o=t;else try{await e.compute(t,i,s,l)&&(a=!0)}catch(d){(0,n.M_)(d)}}return a?l:o&&r?(await e.compute(o,i,s,l),l):[]}function v(e,t){const{colorProvider:i}=e.get(c.ILanguageFeaturesService),s=e.get(a.IModelService).getModel(t);if(!s)throw(0,n.Qg)();return{model:s,colorProviderRegistry:i,isDefaultColorDecoratorsEnabled:e.get(d.pG).getValue("editor.defaultColorDecorators",{resource:t})}}l.w.registerCommand("_executeDocumentColorProvider",(function(e,...t){const[i]=t;if(!(i instanceof r.r))throw(0,n.Qg)();const{model:o,colorProviderRegistry:a,isDefaultColorDecoratorsEnabled:l}=v(e,i);return _(new m,a,o,s.XO.None,l)})),l.w.registerCommand("_executeColorPresentationProvider",(function(e,...t){const[i,a]=t,{uri:l,range:c}=a;if(!(l instanceof r.r)||!Array.isArray(i)||4!==i.length||!o.Q.isIRange(c))throw(0,n.Qg)();const{model:h,colorProviderRegistry:d,isDefaultColorDecoratorsEnabled:u}=v(e,l),[g,p,m,C]=i;return _(new f({range:c,color:{red:g,green:p,blue:m,alpha:C}}),d,h,s.XO.None,u)}))},31659:(e,t,i)=>{"use strict";var s=i(5662),n=i(31450),r=i(36677),o=i(9772),a=i(28712),l=i(77011),c=i(57039);class h extends s.jG{static{this.ID="editor.contrib.colorContribution"}constructor(e){super(),this._editor=e,this._register(e.onMouseDown((e=>this.onMouseDown(e))))}dispose(){super.dispose()}onMouseDown(e){const t=this._editor.getOption(149);if("click"!==t&&"clickAndHover"!==t)return;const i=e.target;if(6!==i.type)return;if(!i.detail.injectedText)return;if(i.detail.injectedText.options.attachedData!==o.nM)return;if(!i.range)return;const s=this._editor.getContribution(l.A.ID);if(s&&!s.isColorPickerVisible){const e=new r.Q(i.range.startLineNumber,i.range.startColumn+1,i.range.endLineNumber,i.range.endColumn+1);s.showContentHover(e,1,0,!1,!0)}}}(0,n.HW)(h.ID,h,2),c.B2.register(a.BJ)},9772:(e,t,i)=>{"use strict";i.d(t,{mn:()=>S,nM:()=>E});var s,n=i(90766),r=i(47661),o=i(64383),a=i(41234),l=i(5662),c=i(78381),h=i(91508),d=i(37734),u=i(31450),g=i(36677),p=i(87289),m=i(32500),f=i(56942),_=i(68310),v=i(84001),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},b=function(e,t){return function(i,s){t(i,s,e)}};const E=Object.create({});let S=class extends l.jG{static{s=this}static{this.ID="editor.contrib.colorDetector"}static{this.RECOMPUTE_TIME=1e3}constructor(e,t,i,n){super(),this._editor=e,this._configurationService=t,this._languageFeaturesService=i,this._localToDispose=this._register(new l.Cm),this._decorationsIds=[],this._colorDatas=new Map,this._colorDecoratorIds=this._editor.createDecorationsCollection(),this._ruleFactory=new d.Qn(this._editor),this._decoratorLimitReporter=new y,this._colorDecorationClassRefs=this._register(new l.Cm),this._debounceInformation=n.for(i.colorProvider,"Document Colors",{min:s.RECOMPUTE_TIME}),this._register(e.onDidChangeModel((()=>{this._isColorDecoratorsEnabled=this.isEnabled(),this.updateColors()}))),this._register(e.onDidChangeModelLanguage((()=>this.updateColors()))),this._register(i.colorProvider.onDidChange((()=>this.updateColors()))),this._register(e.onDidChangeConfiguration((e=>{const t=this._isColorDecoratorsEnabled;this._isColorDecoratorsEnabled=this.isEnabled(),this._isDefaultColorDecoratorsEnabled=this._editor.getOption(148);const i=t!==this._isColorDecoratorsEnabled||e.hasChanged(21),s=e.hasChanged(148);(i||s)&&(this._isColorDecoratorsEnabled?this.updateColors():this.removeAllDecorations())}))),this._timeoutTimer=null,this._computePromise=null,this._isColorDecoratorsEnabled=this.isEnabled(),this._isDefaultColorDecoratorsEnabled=this._editor.getOption(148),this.updateColors()}isEnabled(){const e=this._editor.getModel();if(!e)return!1;const t=e.getLanguageId(),i=this._configurationService.getValue(t);if(i&&"object"===typeof i){const e=i.colorDecorators;if(e&&void 0!==e.enable&&!e.enable)return e.enable}return this._editor.getOption(20)}static get(e){return e.getContribution(this.ID)}dispose(){this.stop(),this.removeAllDecorations(),super.dispose()}updateColors(){if(this.stop(),!this._isColorDecoratorsEnabled)return;const e=this._editor.getModel();e&&this._languageFeaturesService.colorProvider.has(e)&&(this._localToDispose.add(this._editor.onDidChangeModelContent((()=>{this._timeoutTimer||(this._timeoutTimer=new n.pc,this._timeoutTimer.cancelAndSet((()=>{this._timeoutTimer=null,this.beginCompute()}),this._debounceInformation.get(e)))}))),this.beginCompute())}async beginCompute(){this._computePromise=(0,n.SS)((async e=>{const t=this._editor.getModel();if(!t)return[];const i=new c.W(!1),s=await(0,_.j)(this._languageFeaturesService.colorProvider,t,e,this._isDefaultColorDecoratorsEnabled);return this._debounceInformation.update(t,i.elapsed()),s}));try{const e=await this._computePromise;this.updateDecorations(e),this.updateColorDecorators(e),this._computePromise=null}catch(e){(0,o.dz)(e)}}stop(){this._timeoutTimer&&(this._timeoutTimer.cancel(),this._timeoutTimer=null),this._computePromise&&(this._computePromise.cancel(),this._computePromise=null),this._localToDispose.clear()}updateDecorations(e){const t=e.map((e=>({range:{startLineNumber:e.colorInfo.range.startLineNumber,startColumn:e.colorInfo.range.startColumn,endLineNumber:e.colorInfo.range.endLineNumber,endColumn:e.colorInfo.range.endColumn},options:p.kI.EMPTY})));this._editor.changeDecorations((i=>{this._decorationsIds=i.deltaDecorations(this._decorationsIds,t),this._colorDatas=new Map,this._decorationsIds.forEach(((t,i)=>this._colorDatas.set(t,e[i])))}))}updateColorDecorators(e){this._colorDecorationClassRefs.clear();const t=[],i=this._editor.getOption(21);for(let n=0;nthis._colorDatas.has(e.id)));return 0===i.length?null:this._colorDatas.get(i[0].id)}isColorDecoration(e){return this._colorDecoratorIds.has(e)}};S=s=C([b(1,v.pG),b(2,f.ILanguageFeaturesService),b(3,m.ILanguageFeatureDebounceService)],S);class y{constructor(){this._onDidChange=new a.vl,this._computed=0,this._limited=!1}update(e,t){e===this._computed&&t===this._limited||(this._computed=e,this._limited=t,this._onDidChange.fire())}}(0,u.HW)(S.ID,S,1)},28712:(e,t,i)=>{"use strict";i.d(t,{BJ:()=>P,WE:()=>U});var s=i(90766),n=i(18447),r=i(47661),o=i(5662),a=i(36677),l=i(68310),c=i(9772),h=i(41234);class d{get color(){return this._color}set color(e){this._color.equals(e)||(this._color=e,this._onDidChangeColor.fire(e))}get presentation(){return this.colorPresentations[this.presentationIndex]}get colorPresentations(){return this._colorPresentations}set colorPresentations(e){this._colorPresentations=e,this.presentationIndex>e.length-1&&(this.presentationIndex=0),this._onDidChangePresentation.fire(this.presentation)}constructor(e,t,i){this.presentationIndex=i,this._onColorFlushed=new h.vl,this.onColorFlushed=this._onColorFlushed.event,this._onDidChangeColor=new h.vl,this.onDidChangeColor=this._onDidChangeColor.event,this._onDidChangePresentation=new h.vl,this.onDidChangePresentation=this._onDidChangePresentation.event,this.originalColor=e,this._color=e,this._colorPresentations=t}selectNextColorPresentation(){this.presentationIndex=(this.presentationIndex+1)%this.colorPresentations.length,this.flushColor(),this._onDidChangePresentation.fire(this.presentation)}guessColorPresentation(e,t){let i=-1;for(let s=0;s{this.backgroundColor=e.getColor(C.WfR)||r.Q1.white}))),this._register(g.ko(this._pickedColorNode,g.Bx.CLICK,(()=>this.model.selectNextColorPresentation()))),this._register(g.ko(this._originalColorNode,g.Bx.CLICK,(()=>{this.model.color=this.model.originalColor,this.model.flushColor()}))),this._register(t.onDidChangeColor(this.onDidChangeColor,this)),this._register(t.onDidChangePresentation(this.onDidChangePresentation,this)),this._pickedColorNode.style.backgroundColor=r.Q1.Format.CSS.format(t.color)||"",this._pickedColorNode.classList.toggle("light",t.color.rgba.a<.5?this.backgroundColor.isLighter():t.color.isLighter()),this.onDidChangeColor(this.model.color),this.showingStandaloneColorPicker&&(this._domNode.classList.add("standalone-colorpicker"),this._closeButton=this._register(new y(this._domNode)))}get closeButton(){return this._closeButton}get pickedColorNode(){return this._pickedColorNode}get originalColorNode(){return this._originalColorNode}onDidChangeColor(e){this._pickedColorNode.style.backgroundColor=r.Q1.Format.CSS.format(e)||"",this._pickedColorNode.classList.toggle("light",e.rgba.a<.5?this.backgroundColor.isLighter():e.isLighter()),this.onDidChangePresentation()}onDidChangePresentation(){this._pickedColorPresentation.textContent=this.model.presentation?this.model.presentation.label:""}}class y extends o.jG{constructor(e){super(),this._onClicked=this._register(new h.vl),this.onClicked=this._onClicked.event,this._button=document.createElement("div"),this._button.classList.add("close-button"),g.BC(e,this._button);const t=document.createElement("div");t.classList.add("close-button-inner-div"),g.BC(this._button,t);g.BC(t,E(".button"+_.L.asCSSSelector((0,b.pU)("color-picker-close",f.W.close,(0,v.kg)("closeIcon","Icon to close the color picker"))))).classList.add("close-icon"),this._register(g.ko(this._button,g.Bx.CLICK,(()=>{this._onClicked.fire()})))}}class w extends o.jG{constructor(e,t,i,s=!1){super(),this.model=t,this.pixelRatio=i,this._insertButton=null,this._domNode=E(".colorpicker-body"),g.BC(e,this._domNode),this._saturationBox=new L(this._domNode,this.model,this.pixelRatio),this._register(this._saturationBox),this._register(this._saturationBox.onDidChange(this.onDidSaturationValueChange,this)),this._register(this._saturationBox.onColorFlushed(this.flushColor,this)),this._opacityStrip=new T(this._domNode,this.model,s),this._register(this._opacityStrip),this._register(this._opacityStrip.onDidChange(this.onDidOpacityChange,this)),this._register(this._opacityStrip.onColorFlushed(this.flushColor,this)),this._hueStrip=new x(this._domNode,this.model,s),this._register(this._hueStrip),this._register(this._hueStrip.onDidChange(this.onDidHueChange,this)),this._register(this._hueStrip.onColorFlushed(this.flushColor,this)),s&&(this._insertButton=this._register(new k(this._domNode)),this._domNode.classList.add("standalone-colorpicker"))}flushColor(){this.model.flushColor()}onDidSaturationValueChange({s:e,v:t}){const i=this.model.color.hsva;this.model.color=new r.Q1(new r.$J(i.h,e,t,i.a))}onDidOpacityChange(e){const t=this.model.color.hsva;this.model.color=new r.Q1(new r.$J(t.h,t.s,t.v,e))}onDidHueChange(e){const t=this.model.color.hsva,i=360*(1-e);this.model.color=new r.Q1(new r.$J(360===i?0:i,t.s,t.v,t.a))}get domNode(){return this._domNode}get saturationBox(){return this._saturationBox}get enterButton(){return this._insertButton}layout(){this._saturationBox.layout(),this._opacityStrip.layout(),this._hueStrip.layout()}}class L extends o.jG{constructor(e,t,i){super(),this.model=t,this.pixelRatio=i,this._onDidChange=new h.vl,this.onDidChange=this._onDidChange.event,this._onColorFlushed=new h.vl,this.onColorFlushed=this._onColorFlushed.event,this._domNode=E(".saturation-wrap"),g.BC(e,this._domNode),this._canvas=document.createElement("canvas"),this._canvas.className="saturation-box",g.BC(this._domNode,this._canvas),this.selection=E(".saturation-selection"),g.BC(this._domNode,this.selection),this.layout(),this._register(g.ko(this._domNode,g.Bx.POINTER_DOWN,(e=>this.onPointerDown(e)))),this._register(this.model.onDidChangeColor(this.onDidChangeColor,this)),this.monitor=null}get domNode(){return this._domNode}onPointerDown(e){if(!e.target||!(e.target instanceof Element))return;this.monitor=this._register(new p._);const t=g.BK(this._domNode);e.target!==this.selection&&this.onDidChangePosition(e.offsetX,e.offsetY),this.monitor.startMonitoring(e.target,e.pointerId,e.buttons,(e=>this.onDidChangePosition(e.pageX-t.left,e.pageY-t.top)),(()=>null));const i=g.ko(e.target.ownerDocument,g.Bx.POINTER_UP,(()=>{this._onColorFlushed.fire(),i.dispose(),this.monitor&&(this.monitor.stopMonitoring(!0),this.monitor=null)}),!0)}onDidChangePosition(e,t){const i=Math.max(0,Math.min(1,e/this.width)),s=Math.max(0,Math.min(1,1-t/this.height));this.paintSelection(i,s),this._onDidChange.fire({s:i,v:s})}layout(){this.width=this._domNode.offsetWidth,this.height=this._domNode.offsetHeight,this._canvas.width=this.width*this.pixelRatio,this._canvas.height=this.height*this.pixelRatio,this.paint();const e=this.model.color.hsva;this.paintSelection(e.s,e.v)}paint(){const e=this.model.color.hsva,t=new r.Q1(new r.$J(e.h,1,1,1)),i=this._canvas.getContext("2d"),s=i.createLinearGradient(0,0,this._canvas.width,0);s.addColorStop(0,"rgba(255, 255, 255, 1)"),s.addColorStop(.5,"rgba(255, 255, 255, 0.5)"),s.addColorStop(1,"rgba(255, 255, 255, 0)");const n=i.createLinearGradient(0,0,0,this._canvas.height);n.addColorStop(0,"rgba(0, 0, 0, 0)"),n.addColorStop(1,"rgba(0, 0, 0, 1)"),i.rect(0,0,this._canvas.width,this._canvas.height),i.fillStyle=r.Q1.Format.CSS.format(t),i.fill(),i.fillStyle=s,i.fill(),i.fillStyle=n,i.fill()}paintSelection(e,t){this.selection.style.left=e*this.width+"px",this.selection.style.top=this.height-t*this.height+"px"}onDidChangeColor(e){if(this.monitor&&this.monitor.isMonitoring())return;this.paint();const t=e.hsva;this.paintSelection(t.s,t.v)}}class R extends o.jG{constructor(e,t,i=!1){super(),this.model=t,this._onDidChange=new h.vl,this.onDidChange=this._onDidChange.event,this._onColorFlushed=new h.vl,this.onColorFlushed=this._onColorFlushed.event,i?(this.domNode=g.BC(e,E(".standalone-strip")),this.overlay=g.BC(this.domNode,E(".standalone-overlay"))):(this.domNode=g.BC(e,E(".strip")),this.overlay=g.BC(this.domNode,E(".overlay"))),this.slider=g.BC(this.domNode,E(".slider")),this.slider.style.top="0px",this._register(g.ko(this.domNode,g.Bx.POINTER_DOWN,(e=>this.onPointerDown(e)))),this._register(t.onDidChangeColor(this.onDidChangeColor,this)),this.layout()}layout(){this.height=this.domNode.offsetHeight-this.slider.offsetHeight;const e=this.getValue(this.model.color);this.updateSliderPosition(e)}onDidChangeColor(e){const t=this.getValue(e);this.updateSliderPosition(t)}onPointerDown(e){if(!e.target||!(e.target instanceof Element))return;const t=this._register(new p._),i=g.BK(this.domNode);this.domNode.classList.add("grabbing"),e.target!==this.slider&&this.onDidChangeTop(e.offsetY),t.startMonitoring(e.target,e.pointerId,e.buttons,(e=>this.onDidChangeTop(e.pageY-i.top)),(()=>null));const s=g.ko(e.target.ownerDocument,g.Bx.POINTER_UP,(()=>{this._onColorFlushed.fire(),s.dispose(),t.stopMonitoring(!0),this.domNode.classList.remove("grabbing")}),!0)}onDidChangeTop(e){const t=Math.max(0,Math.min(1,1-e/this.height));this.updateSliderPosition(t),this._onDidChange.fire(t)}updateSliderPosition(e){this.slider.style.top=(1-e)*this.height+"px"}}class T extends R{constructor(e,t,i=!1){super(e,t,i),this.domNode.classList.add("opacity-strip"),this.onDidChangeColor(this.model.color)}onDidChangeColor(e){super.onDidChangeColor(e);const{r:t,g:i,b:s}=e.rgba,n=new r.Q1(new r.bU(t,i,s,1)),o=new r.Q1(new r.bU(t,i,s,0));this.overlay.style.background=`linear-gradient(to bottom, ${n} 0%, ${o} 100%)`}getValue(e){return e.hsva.a}}class x extends R{constructor(e,t,i=!1){super(e,t,i),this.domNode.classList.add("hue-strip")}getValue(e){return 1-e.hsva.h/360}}class k extends o.jG{constructor(e){super(),this._onClicked=this._register(new h.vl),this.onClicked=this._onClicked.event,this._button=g.BC(e,document.createElement("button")),this._button.classList.add("insert-button"),this._button.textContent="Insert",this._register(g.ko(this._button,g.Bx.CLICK,(()=>{this._onClicked.fire()})))}get button(){return this._button}}class A extends m.x{constructor(e,t,i,s,n=!1){super(),this.model=t,this.pixelRatio=i,this._register(u.c.getInstance(g.zk(e)).onDidChange((()=>this.layout()))),this._domNode=E(".colorpicker-widget"),e.appendChild(this._domNode),this.header=this._register(new S(this._domNode,this.model,s,n)),this.body=this._register(new w(this._domNode,this.model,this.pixelRatio,n))}layout(){this.body.layout()}get domNode(){return this._domNode}}var N=i(57039),I=i(47612),O=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},D=function(e,t){return function(i,s){t(i,s,e)}};class M{constructor(e,t,i,s){this.owner=e,this.range=t,this.model=i,this.provider=s,this.forceShowAtRange=!0}isValidForHoverAnchor(e){return 1===e.type&&this.range.startColumn<=e.range.startColumn&&this.range.endColumn>=e.range.endColumn}}let P=class{constructor(e,t){this._editor=e,this._themeService=t,this.hoverOrdinal=2}computeSync(e,t){return[]}computeAsync(e,t,i){return s.AE.fromPromise(this._computeAsync(e,t,i))}async _computeAsync(e,t,i){if(!this._editor.hasModel())return[];const s=c.mn.get(this._editor);if(!s)return[];for(const n of t){if(!s.isColorDecoration(n))continue;const e=s.getColorData(n.range.getStartPosition());if(e){return[await H(this,this._editor.getModel(),e.colorInfo,e.provider)]}}return[]}renderHoverParts(e,t){const i=B(this,this._editor,this._themeService,t,e);if(!i)return new N.Ke([]);this._colorPicker=i.colorPicker;const s={hoverPart:i.hoverPart,hoverElement:this._colorPicker.domNode,dispose(){i.disposables.dispose()}};return new N.Ke([s])}handleResize(){this._colorPicker?.layout()}isColorPickerVisible(){return!!this._colorPicker}};P=O([D(1,I.Gy)],P);class F{constructor(e,t,i,s){this.owner=e,this.range=t,this.model=i,this.provider=s}}let U=class{constructor(e,t){this._editor=e,this._themeService=t,this._color=null}async createColorHover(e,t,i){if(!this._editor.hasModel())return null;if(!c.mn.get(this._editor))return null;const s=await(0,l.j)(i,this._editor.getModel(),n.XO.None);let r=null,o=null;for(const n of s){const t=n.colorInfo;a.Q.containsRange(t.range,e.range)&&(r=t,o=n.provider)}const h=r??e,d=o??t,u=!!r;return{colorHover:await H(this,this._editor.getModel(),h,d),foundInEditor:u}}async updateEditorModel(e){if(!this._editor.hasModel())return;const t=e.model;let i=new a.Q(e.range.startLineNumber,e.range.startColumn,e.range.endLineNumber,e.range.endColumn);this._color&&(await V(this._editor.getModel(),t,this._color,i,e),i=W(this._editor,i,t))}renderHoverParts(e,t){return B(this,this._editor,this._themeService,t,e)}set color(e){this._color=e}get color(){return this._color}};async function H(e,t,i,s){const o=t.getValueInRange(i.range),{red:c,green:h,blue:u,alpha:g}=i.color,p=new r.bU(Math.round(255*c),Math.round(255*h),Math.round(255*u),g),m=new r.Q1(p),f=await(0,l.R)(t,i,s,n.XO.None),_=new d(m,[],0);return _.colorPresentations=f||[],_.guessColorPresentation(m,o),e instanceof P?new M(e,a.Q.lift(i.range),_,s):new F(e,a.Q.lift(i.range),_,s)}function B(e,t,i,s,n){if(0===s.length||!t.hasModel())return;if(n.setMinimumDimensions){const e=t.getOption(67)+8;n.setMinimumDimensions(new g.fg(302,e))}const r=new o.Cm,l=s[0],c=t.getModel(),h=l.model,d=r.add(new A(n.fragment,h,t.getOption(144),i,e instanceof U));let u=!1,p=new a.Q(l.range.startLineNumber,l.range.startColumn,l.range.endLineNumber,l.range.endColumn);if(e instanceof U){const t=l.model.color;e.color=t,V(c,h,t,p,l),r.add(h.onColorFlushed((t=>{e.color=t})))}else r.add(h.onColorFlushed((async e=>{await V(c,h,e,p,l),u=!0,p=W(t,p,h)})));return r.add(h.onDidChangeColor((e=>{V(c,h,e,p,l)}))),r.add(t.onDidChangeModelContent((e=>{u?u=!1:(n.hide(),t.focus())}))),{hoverPart:l,colorPicker:d,disposables:r}}function W(e,t,i){const s=[],n=i.presentation.textEdit??{range:t,text:i.presentation.label,forceMoveMarkers:!1};s.push(n),i.presentation.additionalTextEdits&&s.push(...i.presentation.additionalTextEdits);const r=a.Q.lift(n.range),o=e.getModel()._setTrackedRange(null,r,3);return e.executeEdits("colorpicker",s),e.pushUndoStop(),e.getModel()._getTrackedRange(o)??r}async function V(e,t,i,s,r){const o=await(0,l.R)(e,{range:s,color:{red:i.rgba.r/255,green:i.rgba.g/255,blue:i.rgba.b/255,alpha:i.rgba.a}},r.provider,n.XO.None);t.colorPresentations=o||[]}U=O([D(1,I.Gy)],U)},52363:(e,t,i)=>{"use strict";i.d(t,{L:()=>h});var s=i(47661),n=i(5662),r=i(56942),o=i(72466),a=i(10920),l=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},c=function(e,t){return function(i,s){t(i,s,e)}};let h=class{constructor(e){this._editorWorkerService=e}async provideDocumentColors(e,t){return this._editorWorkerService.computeDefaultDocumentColors(e.uri)}provideColorPresentations(e,t,i){const n=t.range,r=t.color,o=r.alpha,a=new s.Q1(new s.bU(Math.round(255*r.red),Math.round(255*r.green),Math.round(255*r.blue),o)),l=o?s.Q1.Format.CSS.formatRGB(a):s.Q1.Format.CSS.formatRGBA(a),c=o?s.Q1.Format.CSS.formatHSL(a):s.Q1.Format.CSS.formatHSLA(a),h=o?s.Q1.Format.CSS.formatHex(a):s.Q1.Format.CSS.formatHexA(a),d=[];return d.push({label:l,textEdit:{range:n,text:l}}),d.push({label:c,textEdit:{range:n,text:c}}),d.push({label:h,textEdit:{range:n,text:h}}),d}};h=l([c(0,a.IEditorWorkerService)],h);let d=class extends n.jG{constructor(e,t){super(),this._register(e.colorProvider.register("*",new h(t)))}};d=l([c(0,r.ILanguageFeaturesService),c(1,a.IEditorWorkerService)],d),(0,o.x)(d)},99822:(e,t,i)=>{"use strict";var s,n,r=i(31450),o=i(78209),a=i(5662),l=i(28712),c=i(63591),h=i(9270),d=i(98031),u=i(41234),g=i(56942),p=i(60002),m=i(32848),f=i(52363),_=i(8597),v=(i(53396),i(10920)),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},b=function(e,t){return function(i,s){t(i,s,e)}};let E=class extends a.jG{static{s=this}static{this.ID="editor.contrib.standaloneColorPickerController"}constructor(e,t,i){super(),this._editor=e,this._instantiationService=i,this._standaloneColorPickerWidget=null,this._standaloneColorPickerVisible=p.R.standaloneColorPickerVisible.bindTo(t),this._standaloneColorPickerFocused=p.R.standaloneColorPickerFocused.bindTo(t)}showOrFocus(){this._editor.hasModel()&&(this._standaloneColorPickerVisible.get()?this._standaloneColorPickerFocused.get()||this._standaloneColorPickerWidget?.focus():this._standaloneColorPickerWidget=this._instantiationService.createInstance(S,this._editor,this._standaloneColorPickerVisible,this._standaloneColorPickerFocused))}hide(){this._standaloneColorPickerFocused.set(!1),this._standaloneColorPickerVisible.set(!1),this._standaloneColorPickerWidget?.hide(),this._editor.focus()}insertColor(){this._standaloneColorPickerWidget?.updateEditor(),this.hide()}static get(e){return e.getContribution(s.ID)}};E=s=C([b(1,m.fN),b(2,c._Y)],E),(0,r.HW)(E.ID,E,1);let S=class extends a.jG{static{n=this}static{this.ID="editor.contrib.standaloneColorPickerWidget"}constructor(e,t,i,s,n,r,o){super(),this._editor=e,this._standaloneColorPickerVisible=t,this._standaloneColorPickerFocused=i,this._keybindingService=n,this._languageFeaturesService=r,this._editorWorkerService=o,this.allowEditorOverflow=!0,this._position=void 0,this._body=document.createElement("div"),this._colorHover=null,this._selectionSetInEditor=!1,this._onResult=this._register(new u.vl),this.onResult=this._onResult.event,this._standaloneColorPickerVisible.set(!0),this._standaloneColorPickerParticipant=s.createInstance(l.WE,this._editor),this._position=this._editor._getViewModel()?.getPrimaryCursorState().modelState.position;const a=this._editor.getSelection(),c=a?{startLineNumber:a.startLineNumber,startColumn:a.startColumn,endLineNumber:a.endLineNumber,endColumn:a.endColumn}:{startLineNumber:0,endLineNumber:0,endColumn:0,startColumn:0},h=this._register(_.w5(this._body));this._register(h.onDidBlur((e=>{this.hide()}))),this._register(h.onDidFocus((e=>{this.focus()}))),this._register(this._editor.onDidChangeCursorPosition((()=>{this._selectionSetInEditor?this._selectionSetInEditor=!1:this.hide()}))),this._register(this._editor.onMouseMove((e=>{const t=e.target.element?.classList;t&&t.contains("colorpicker-color-decoration")&&this.hide()}))),this._register(this.onResult((e=>{this._render(e.value,e.foundInEditor)}))),this._start(c),this._body.style.zIndex="50",this._editor.addContentWidget(this)}updateEditor(){this._colorHover&&this._standaloneColorPickerParticipant.updateEditorModel(this._colorHover)}getId(){return n.ID}getDomNode(){return this._body}getPosition(){if(!this._position)return null;const e=this._editor.getOption(60).above;return{position:this._position,secondaryPosition:this._position,preference:e?[1,2]:[2,1],positionAffinity:2}}hide(){this.dispose(),this._standaloneColorPickerVisible.set(!1),this._standaloneColorPickerFocused.set(!1),this._editor.removeContentWidget(this),this._editor.focus()}focus(){this._standaloneColorPickerFocused.set(!0),this._body.focus()}async _start(e){const t=await this._computeAsync(e);t&&this._onResult.fire(new y(t.result,t.foundInEditor))}async _computeAsync(e){if(!this._editor.hasModel())return null;const t={range:e,color:{red:0,green:0,blue:0,alpha:1}},i=await this._standaloneColorPickerParticipant.createColorHover(t,new f.L(this._editorWorkerService),this._languageFeaturesService.colorProvider);return i?{result:i.colorHover,foundInEditor:i.foundInEditor}:null}_render(e,t){const i=document.createDocumentFragment(),s={fragment:i,statusBar:this._register(new h.L(this._keybindingService)),onContentsChanged:()=>{},hide:()=>this.hide()};this._colorHover=e;const n=this._standaloneColorPickerParticipant.renderHoverParts(s,[e]);if(!n)return;this._register(n.disposables);const r=n.colorPicker;this._body.classList.add("standalone-colorpicker-body"),this._body.style.maxHeight=Math.max(this._editor.getLayoutInfo().height/4,250)+"px",this._body.style.maxWidth=Math.max(.66*this._editor.getLayoutInfo().width,500)+"px",this._body.tabIndex=0,this._body.appendChild(i),r.layout();const o=r.body,a=o.saturationBox.domNode.clientWidth,l=o.domNode.clientWidth-a-22-8,c=r.body.enterButton;c?.onClicked((()=>{this.updateEditor(),this.hide()}));const d=r.header;d.pickedColorNode.style.width=a+8+"px";d.originalColorNode.style.width=l+"px";const u=r.header.closeButton;u?.onClicked((()=>{this.hide()})),t&&(c&&(c.button.textContent="Replace"),this._selectionSetInEditor=!0,this._editor.setSelection(e.range)),this._editor.layoutContentWidget(this)}};S=n=C([b(3,c._Y),b(4,d.b),b(5,g.ILanguageFeaturesService),b(6,v.IEditorWorkerService)],S);class y{constructor(e,t){this.value=e,this.foundInEditor=t}}var w=i(27195);class L extends r.qO{constructor(){super({id:"editor.action.showOrFocusStandaloneColorPicker",title:{...(0,o.aS)("showOrFocusStandaloneColorPicker","Show or Focus Standalone Color Picker"),mnemonicTitle:(0,o.kg)({key:"mishowOrFocusStandaloneColorPicker",comment:["&& denotes a mnemonic"]},"&&Show or Focus Standalone Color Picker")},precondition:void 0,menu:[{id:w.D8.CommandPalette}],metadata:{description:(0,o.aS)("showOrFocusStandaloneColorPickerDescription","Show or focus a standalone color picker which uses the default color provider. It displays hex/rgb/hsl colors.")}})}runEditorCommand(e,t){E.get(t)?.showOrFocus()}}class R extends r.ks{constructor(){super({id:"editor.action.hideColorPicker",label:(0,o.kg)({key:"hideColorPicker",comment:["Action that hides the color picker"]},"Hide the Color Picker"),alias:"Hide the Color Picker",precondition:p.R.standaloneColorPickerVisible.isEqualTo(!0),kbOpts:{primary:9,weight:100},metadata:{description:(0,o.aS)("hideColorPickerDescription","Hide the standalone color picker.")}})}run(e,t){E.get(t)?.hide()}}class T extends r.ks{constructor(){super({id:"editor.action.insertColorWithStandaloneColorPicker",label:(0,o.kg)({key:"insertColorWithStandaloneColorPicker",comment:["Action that inserts color with standalone color picker"]},"Insert Color with Standalone Color Picker"),alias:"Insert Color with Standalone Color Picker",precondition:p.R.standaloneColorPickerFocused.isEqualTo(!0),kbOpts:{primary:3,weight:100},metadata:{description:(0,o.aS)("insertColorWithStandaloneColorPickerDescription","Insert hex/rgb/hsl colors with the focused standalone color picker.")}})}run(e,t){E.get(t)?.insertColor()}}(0,r.Fl)(R),(0,r.Fl)(T),(0,w.ug)(L)},40142:(e,t,i)=>{"use strict";var s=i(24939),n=i(31450),r=i(36677),o=i(60002),a=i(17469),l=i(7085),c=i(83069),h=i(75326);class d{constructor(e,t,i){this.languageConfigurationService=i,this._selection=e,this._insertSpace=t,this._usedEndToken=null}static _haystackHasNeedleAtOffset(e,t,i){if(i<0)return!1;const s=t.length;if(i+s>e.length)return!1;for(let n=0;n=65&&s<=90&&s+32===r)&&!(r>=65&&r<=90&&r+32===s)))return!1}return!0}_createOperationsForBlockComment(e,t,i,s,n,o){const a=e.startLineNumber,l=e.startColumn,c=e.endLineNumber,h=e.endColumn,u=n.getLineContent(a),g=n.getLineContent(c);let p,m=u.lastIndexOf(t,l-1+t.length),f=g.indexOf(i,h-1-i.length);if(-1!==m&&-1!==f)if(a===c){u.substring(m+t.length,f).indexOf(i)>=0&&(m=-1,f=-1)}else{const e=u.substring(m+t.length),s=g.substring(0,f);(e.indexOf(i)>=0||s.indexOf(i)>=0)&&(m=-1,f=-1)}-1!==m&&-1!==f?(s&&m+t.length0&&32===g.charCodeAt(f-1)&&(i=" "+i,f-=1),p=d._createRemoveBlockCommentOperations(new r.Q(a,m+t.length+1,c,f+1),t,i)):(p=d._createAddBlockCommentOperations(e,t,i,this._insertSpace),this._usedEndToken=1===p.length?i:null);for(const r of p)o.addTrackedEditOperation(r.range,r.text)}static _createRemoveBlockCommentOperations(e,t,i){const s=[];return r.Q.isEmpty(e)?s.push(l.k.delete(new r.Q(e.startLineNumber,e.startColumn-t.length,e.endLineNumber,e.endColumn+i.length))):(s.push(l.k.delete(new r.Q(e.startLineNumber,e.startColumn-t.length,e.startLineNumber,e.startColumn))),s.push(l.k.delete(new r.Q(e.endLineNumber,e.endColumn,e.endLineNumber,e.endColumn+i.length)))),s}static _createAddBlockCommentOperations(e,t,i,s){const n=[];return r.Q.isEmpty(e)?n.push(l.k.replace(new r.Q(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn),t+" "+i)):(n.push(l.k.insert(new c.y(e.startLineNumber,e.startColumn),t+(s?" ":""))),n.push(l.k.insert(new c.y(e.endLineNumber,e.endColumn),(s?" ":"")+i))),n}getEditOperations(e,t){const i=this._selection.startLineNumber,s=this._selection.startColumn;e.tokenization.tokenizeIfCheap(i);const n=e.getLanguageIdAtPosition(i,s),r=this.languageConfigurationService.getLanguageConfiguration(n).comments;r&&r.blockCommentStartToken&&r.blockCommentEndToken&&this._createOperationsForBlockComment(this._selection,r.blockCommentStartToken,r.blockCommentEndToken,this._insertSpace,e,t)}computeCursorState(e,t){const i=t.getInverseEditOperations();if(2===i.length){const e=i[0],t=i[1];return new h.L(e.range.endLineNumber,e.range.endColumn,t.range.startLineNumber,t.range.startColumn)}{const e=i[0].range,t=this._usedEndToken?-this._usedEndToken.length-1:0;return new h.L(e.endLineNumber,e.endColumn+t,e.endLineNumber,e.endColumn+t)}}}var u=i(91508);class g{constructor(e,t,i,s,n,r,o){this.languageConfigurationService=e,this._selection=t,this._indentSize=i,this._type=s,this._insertSpace=n,this._selectionId=null,this._deltaColumn=0,this._moveEndPositionDown=!1,this._ignoreEmptyLines=r,this._ignoreFirstLine=o||!1}static _gatherPreflightCommentStrings(e,t,i,s){e.tokenization.tokenizeIfCheap(t);const n=e.getLanguageIdAtPosition(t,1),r=s.getLanguageConfiguration(n).comments,o=r?r.lineCommentToken:null;if(!o)return null;const a=[];for(let l=0,c=i-t+1;lo?n-1:n}}}var p=i(78209),m=i(27195);class f extends n.ks{constructor(e,t){super(t),this._type=e}run(e,t){const i=e.get(a.JZ);if(!t.hasModel())return;const s=[],n=t.getModel().getOptions(),o=t.getOption(23),l=t.getSelections().map(((e,t)=>({selection:e,index:t,ignoreFirstLine:!1})));l.sort(((e,t)=>r.Q.compareRangesUsingStarts(e.selection,t.selection)));let c=l[0];for(let r=1;r{"use strict";i.d(t,{d:()=>b});var s,n=i(8597),r=i(5646),o=i(36921),a=i(5662),l=i(98067),c=i(31450),h=i(60002),d=i(78209),u=i(27195),g=i(32848),p=i(47508),m=i(98031),f=i(84001),_=i(37227),v=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},C=function(e,t){return function(i,s){t(i,s,e)}};let b=class{static{s=this}static{this.ID="editor.contrib.contextmenu"}static get(e){return e.getContribution(s.ID)}constructor(e,t,i,s,r,o,l,c){this._contextMenuService=t,this._contextViewService=i,this._contextKeyService=s,this._keybindingService=r,this._menuService=o,this._configurationService=l,this._workspaceContextService=c,this._toDispose=new a.Cm,this._contextMenuIsBeingShownCount=0,this._editor=e,this._toDispose.add(this._editor.onContextMenu((e=>this._onContextMenu(e)))),this._toDispose.add(this._editor.onMouseWheel((e=>{if(this._contextMenuIsBeingShownCount>0){const t=this._contextViewService.getContextViewElement(),i=e.srcElement;i.shadowRoot&&n.jG(t)===i.shadowRoot||this._contextViewService.hideContextView()}}))),this._toDispose.add(this._editor.onKeyDown((e=>{this._editor.getOption(24)&&58===e.keyCode&&(e.preventDefault(),e.stopPropagation(),this.showContextMenu())})))}_onContextMenu(e){if(!this._editor.hasModel())return;if(!this._editor.getOption(24))return this._editor.focus(),void(e.target.position&&!this._editor.getSelection().containsPosition(e.target.position)&&this._editor.setPosition(e.target.position));if(12===e.target.type)return;if(6===e.target.type&&e.target.detail.injectedText)return;if(e.event.preventDefault(),e.event.stopPropagation(),11===e.target.type)return this._showScrollbarContextMenu(e.event);if(6!==e.target.type&&7!==e.target.type&&1!==e.target.type)return;if(this._editor.focus(),e.target.position){let t=!1;for(const i of this._editor.getSelections())if(i.containsPosition(e.target.position)){t=!0;break}t||this._editor.setPosition(e.target.position)}let t=null;1!==e.target.type&&(t=e.event),this.showContextMenu(t)}showContextMenu(e){if(!this._editor.getOption(24))return;if(!this._editor.hasModel())return;const t=this._getMenuActions(this._editor.getModel(),this._editor.contextMenuId);t.length>0&&this._doShowContextMenu(t,e)}_getMenuActions(e,t){const i=[],s=this._menuService.getMenuActions(t,this._contextKeyService,{arg:e.uri});for(const n of s){const[,t]=n;let s=0;for(const n of t)if(n instanceof u.nI){const t=this._getMenuActions(e,n.item.submenu);t.length>0&&(i.push(new o.YH(n.id,n.label,t)),s++)}else i.push(n),s++;s&&i.push(new o.wv)}return i.length&&i.pop(),i}_doShowContextMenu(e,t=null){if(!this._editor.hasModel())return;const i=this._editor.getOption(60);this._editor.updateOptions({hover:{enabled:!1}});let s=t;if(!s){this._editor.revealPosition(this._editor.getPosition(),1),this._editor.render();const e=this._editor.getScrolledVisiblePosition(this._editor.getPosition()),t=n.BK(this._editor.getDomNode()),i=t.left+e.left,r=t.top+e.top+e.height;s={x:i,y:r}}const o=this._editor.getOption(128)&&!l.un;this._contextMenuIsBeingShownCount++,this._contextMenuService.showContextMenu({domForShadowRoot:o?this._editor.getOverflowWidgetsDomNode()??this._editor.getDomNode():void 0,getAnchor:()=>s,getActions:()=>e,getActionViewItem:e=>{const t=this._keybindingFor(e);if(t)return new r.Z4(e,e,{label:!0,keybinding:t.getLabel(),isMenu:!0});const i=e;return"function"===typeof i.getActionViewItem?i.getActionViewItem():new r.Z4(e,e,{icon:!0,label:!0,isMenu:!0})},getKeyBinding:e=>this._keybindingFor(e),onHide:e=>{this._contextMenuIsBeingShownCount--,this._editor.updateOptions({hover:i})}})}_showScrollbarContextMenu(e){if(!this._editor.hasModel())return;if((0,_.ct)(this._workspaceContextService.getWorkspace()))return;const t=this._editor.getOption(73);let i=0;const s=e=>({id:"menu-action-"+ ++i,label:e.label,tooltip:"",class:void 0,enabled:"undefined"===typeof e.enabled||e.enabled,checked:e.checked,run:e.run}),n=(e,t,n,r,a)=>{if(!t)return s({label:e,enabled:t,run:()=>{}});const l=e=>()=>{this._configurationService.updateValue(n,e)},c=[];for(const i of a)c.push(s({label:i.label,checked:r===i.value,run:l(i.value)}));return((e,t)=>new o.YH("menu-action-"+ ++i,e,t,void 0))(e,c)},r=[];r.push(s({label:d.kg("context.minimap.minimap","Minimap"),checked:t.enabled,run:()=>{this._configurationService.updateValue("editor.minimap.enabled",!t.enabled)}})),r.push(new o.wv),r.push(s({label:d.kg("context.minimap.renderCharacters","Render Characters"),enabled:t.enabled,checked:t.renderCharacters,run:()=>{this._configurationService.updateValue("editor.minimap.renderCharacters",!t.renderCharacters)}})),r.push(n(d.kg("context.minimap.size","Vertical size"),t.enabled,"editor.minimap.size",t.size,[{label:d.kg("context.minimap.size.proportional","Proportional"),value:"proportional"},{label:d.kg("context.minimap.size.fill","Fill"),value:"fill"},{label:d.kg("context.minimap.size.fit","Fit"),value:"fit"}])),r.push(n(d.kg("context.minimap.slider","Slider"),t.enabled,"editor.minimap.showSlider",t.showSlider,[{label:d.kg("context.minimap.slider.mouseover","Mouse Over"),value:"mouseover"},{label:d.kg("context.minimap.slider.always","Always"),value:"always"}]));const a=this._editor.getOption(128)&&!l.un;this._contextMenuIsBeingShownCount++,this._contextMenuService.showContextMenu({domForShadowRoot:a?this._editor.getDomNode():void 0,getAnchor:()=>e,getActions:()=>r,onHide:e=>{this._contextMenuIsBeingShownCount--,this._editor.focus()}})}_keybindingFor(e){return this._keybindingService.lookupKeybinding(e.id)}dispose(){this._contextMenuIsBeingShownCount>0&&this._contextViewService.hideContextView(),this._toDispose.dispose()}};b=s=v([C(1,p.Z),C(2,p.l),C(3,g.fN),C(4,m.b),C(5,u.ez),C(6,f.pG),C(7,_.VR)],b);class E extends c.ks{constructor(){super({id:"editor.action.showContextMenu",label:d.kg("action.showContextMenu.label","Show Editor Context Menu"),alias:"Show Editor Context Menu",precondition:void 0,kbOpts:{kbExpr:h.R.textInputFocus,primary:1092,weight:100}})}run(e,t){b.get(t)?.showContextMenu()}}(0,c.HW)(b.ID,b,2),(0,c.Fl)(E)},32516:(e,t,i)=>{"use strict";var s=i(5662),n=i(31450),r=i(60002),o=i(78209);class a{constructor(e){this.selections=e}equals(e){const t=this.selections.length;if(t!==e.selections.length)return!1;for(let i=0;i{this._undoStack=[],this._redoStack=[]}))),this._register(e.onDidChangeModelContent((e=>{this._undoStack=[],this._redoStack=[]}))),this._register(e.onDidChangeCursorSelection((t=>{if(this._isCursorUndoRedo)return;if(!t.oldSelections)return;if(t.oldModelVersionId!==t.modelVersionId)return;const i=new a(t.oldSelections);this._undoStack.length>0&&this._undoStack[this._undoStack.length-1].cursorState.equals(i)||(this._undoStack.push(new l(i,e.getScrollTop(),e.getScrollLeft())),this._redoStack=[],this._undoStack.length>50&&this._undoStack.shift())})))}cursorUndo(){this._editor.hasModel()&&0!==this._undoStack.length&&(this._redoStack.push(new l(new a(this._editor.getSelections()),this._editor.getScrollTop(),this._editor.getScrollLeft())),this._applyState(this._undoStack.pop()))}cursorRedo(){this._editor.hasModel()&&0!==this._redoStack.length&&(this._undoStack.push(new l(new a(this._editor.getSelections()),this._editor.getScrollTop(),this._editor.getScrollLeft())),this._applyState(this._redoStack.pop()))}_applyState(e){this._isCursorUndoRedo=!0,this._editor.setSelections(e.cursorState.selections),this._editor.setScrollPosition({scrollTop:e.scrollTop,scrollLeft:e.scrollLeft}),this._isCursorUndoRedo=!1}}class h extends n.ks{constructor(){super({id:"cursorUndo",label:o.kg("cursor.undo","Cursor Undo"),alias:"Cursor Undo",precondition:void 0,kbOpts:{kbExpr:r.R.textInputFocus,primary:2099,weight:100}})}run(e,t,i){c.get(t)?.cursorUndo()}}class d extends n.ks{constructor(){super({id:"cursorRedo",label:o.kg("cursor.redo","Cursor Redo"),alias:"Cursor Redo",precondition:void 0})}run(e,t,i){c.get(t)?.cursorRedo()}}(0,n.HW)(c.ID,c,0),(0,n.Fl)(h),(0,n.Fl)(d)},40800:(e,t,i)=>{"use strict";var s=i(25890),n=i(31308),r=i(34309),o=i(92368),a=i(56942),l=i(29999),c=i(5662),h=i(41234),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},u=function(e,t){return function(i,s){t(i,s,e)}};let g=class extends c.jG{constructor(e,t,i){super(),this._textModel=e,this._languageFeaturesService=t,this._outlineModelService=i,this._currentModel=(0,n.FY)(this,void 0);const s=(0,n.yQ)("documentSymbolProvider.onDidChange",this._languageFeaturesService.documentSymbolProvider.onDidChange),r=(0,n.yQ)("_textModel.onDidChangeContent",h.Jh.debounce((e=>this._textModel.onDidChangeContent(e)),(()=>{}),100));this._register((0,n.yC)((async(e,t)=>{s.read(e),r.read(e);const i=t.add(new o.MZ),n=await this._outlineModelService.getOrCreate(this._textModel,i.token);t.isDisposed||this._currentModel.set(n,void 0)})))}getBreadcrumbItems(e,t){const i=this._currentModel.read(t);if(!i)return[];const n=i.asListOfDocumentSymbols().filter((t=>e.contains(t.range.startLineNumber)&&!e.contains(t.range.endLineNumber)));return n.sort((0,s.Hw)((0,s.VE)((e=>e.range.endLineNumber-e.range.startLineNumber),s.U9))),n.map((e=>({name:e.name,kind:e.kind,startLineNumber:e.range.startLineNumber})))}};g=d([u(1,a.ILanguageFeaturesService),u(2,l.gW)],g),r.N.setBreadcrumbsSourceFactory(((e,t)=>t.createInstance(g,e)))},2183:(e,t,i)=>{"use strict";var s=i(5662),n=i(98067),r=i(31450),o=i(83069),a=i(36677),l=i(75326),c=i(87289);class h{constructor(e,t,i){this.selection=e,this.targetPosition=t,this.copy=i,this.targetSelection=null}getEditOperations(e,t){const i=e.getValueInRange(this.selection);this.copy||t.addEditOperation(this.selection,null),t.addEditOperation(new a.Q(this.targetPosition.lineNumber,this.targetPosition.column,this.targetPosition.lineNumber,this.targetPosition.column),i),!this.selection.containsPosition(this.targetPosition)||this.copy&&(this.selection.getEndPosition().equals(this.targetPosition)||this.selection.getStartPosition().equals(this.targetPosition))?this.copy?this.targetSelection=new l.L(this.targetPosition.lineNumber,this.targetPosition.column,this.selection.endLineNumber-this.selection.startLineNumber+this.targetPosition.lineNumber,this.selection.startLineNumber===this.selection.endLineNumber?this.targetPosition.column+this.selection.endColumn-this.selection.startColumn:this.selection.endColumn):this.targetPosition.lineNumber>this.selection.endLineNumber?this.targetSelection=new l.L(this.targetPosition.lineNumber-this.selection.endLineNumber+this.selection.startLineNumber,this.targetPosition.column,this.targetPosition.lineNumber,this.selection.startLineNumber===this.selection.endLineNumber?this.targetPosition.column+this.selection.endColumn-this.selection.startColumn:this.selection.endColumn):this.targetPosition.lineNumberthis._onEditorMouseDown(e)))),this._register(this._editor.onMouseUp((e=>this._onEditorMouseUp(e)))),this._register(this._editor.onMouseDrag((e=>this._onEditorMouseDrag(e)))),this._register(this._editor.onMouseDrop((e=>this._onEditorMouseDrop(e)))),this._register(this._editor.onMouseDropCanceled((()=>this._onEditorMouseDropCanceled()))),this._register(this._editor.onKeyDown((e=>this.onEditorKeyDown(e)))),this._register(this._editor.onKeyUp((e=>this.onEditorKeyUp(e)))),this._register(this._editor.onDidBlurEditorWidget((()=>this.onEditorBlur()))),this._register(this._editor.onDidBlurEditorText((()=>this.onEditorBlur()))),this._mouseDown=!1,this._modifierPressed=!1,this._dragSelection=null}onEditorBlur(){this._removeDecoration(),this._dragSelection=null,this._mouseDown=!1,this._modifierPressed=!1}onEditorKeyDown(e){this._editor.getOption(35)&&!this._editor.getOption(22)&&(d(e)&&(this._modifierPressed=!0),this._mouseDown&&d(e)&&this._editor.updateOptions({mouseStyle:"copy"}))}onEditorKeyUp(e){this._editor.getOption(35)&&!this._editor.getOption(22)&&(d(e)&&(this._modifierPressed=!1),this._mouseDown&&e.keyCode===u.TRIGGER_KEY_VALUE&&this._editor.updateOptions({mouseStyle:"default"}))}_onEditorMouseDown(e){this._mouseDown=!0}_onEditorMouseUp(e){this._mouseDown=!1,this._editor.updateOptions({mouseStyle:"text"})}_onEditorMouseDrag(e){const t=e.target;if(null===this._dragSelection){const e=(this._editor.getSelections()||[]).filter((e=>t.position&&e.containsPosition(t.position)));if(1!==e.length)return;this._dragSelection=e[0]}d(e.event)?this._editor.updateOptions({mouseStyle:"copy"}):this._editor.updateOptions({mouseStyle:"default"}),t.position&&(this._dragSelection.containsPosition(t.position)?this._removeDecoration():this.showAt(t.position))}_onEditorMouseDropCanceled(){this._editor.updateOptions({mouseStyle:"text"}),this._removeDecoration(),this._dragSelection=null,this._mouseDown=!1}_onEditorMouseDrop(e){if(e.target&&(this._hitContent(e.target)||this._hitMargin(e.target))&&e.target.position){const t=new o.y(e.target.position.lineNumber,e.target.position.column);if(null===this._dragSelection){let i=null;if(e.event.shiftKey){const e=this._editor.getSelection();if(e){const{selectionStartLineNumber:s,selectionStartColumn:n}=e;i=[new l.L(s,n,t.lineNumber,t.column)]}}else i=(this._editor.getSelections()||[]).map((e=>e.containsPosition(t)?new l.L(t.lineNumber,t.column,t.lineNumber,t.column):e));this._editor.setSelections(i||[],"mouse",3)}else(!this._dragSelection.containsPosition(t)||(d(e.event)||this._modifierPressed)&&(this._dragSelection.getEndPosition().equals(t)||this._dragSelection.getStartPosition().equals(t)))&&(this._editor.pushUndoStop(),this._editor.executeCommand(u.ID,new h(this._dragSelection,t,d(e.event)||this._modifierPressed)),this._editor.pushUndoStop())}this._editor.updateOptions({mouseStyle:"text"}),this._removeDecoration(),this._dragSelection=null,this._mouseDown=!1}static{this._DECORATION_OPTIONS=c.kI.register({description:"dnd-target",className:"dnd-target"})}showAt(e){this._dndDecorationIds.set([{range:new a.Q(e.lineNumber,e.column,e.lineNumber,e.column),options:u._DECORATION_OPTIONS}]),this._editor.revealPosition(e,1)}_removeDecoration(){this._dndDecorationIds.clear()}_hitContent(e){return 6===e.type||7===e.type}_hitMargin(e){return 2===e.type||3===e.type||4===e.type}dispose(){this._removeDecoration(),this._dragSelection=null,this._mouseDown=!1,this._modifierPressed=!1,super.dispose()}}(0,r.HW)(u.ID,u,2)},58568:(e,t,i)=>{"use strict";var s=i(18447),n=i(631),r=i(79400),o=i(18938),a=i(29999);i(50091).w.registerCommand("_executeDocumentSymbolProvider",(async function(e,...t){const[i]=t;(0,n.j)(r.r.isUri(i));const l=e.get(a.gW),c=e.get(o.ITextModelService),h=await c.createModelReference(i);try{return(await l.getOrCreate(h.object.textEditorModel,s.XO.None)).getTopLevelSymbols()}finally{h.dispose()}}))},29999:(e,t,i)=>{"use strict";i.d(t,{LC:()=>C,e0:()=>b,gW:()=>S,i9:()=>E});var s=i(25890),n=i(18447),r=i(64383),o=i(42522),a=i(74320),l=i(83069),c=i(36677),h=i(32500),d=i(63591),u=i(14718),g=i(23750),p=i(5662),m=i(56942),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};class v{remove(){this.parent?.children.delete(this.id)}static findId(e,t){let i;"string"===typeof e?i=`${t.id}/${e}`:(i=`${t.id}/${e.name}`,void 0!==t.children.get(i)&&(i=`${t.id}/${e.name}_${e.range.startLineNumber}_${e.range.startColumn}`));let s=i;for(let n=0;void 0!==t.children.get(s);n++)s=`${i}_${n}`;return s}static empty(e){return 0===e.children.size}}class C extends v{constructor(e,t,i){super(),this.id=e,this.parent=t,this.symbol=i,this.children=new Map}}class b extends v{constructor(e,t,i,s){super(),this.id=e,this.parent=t,this.label=i,this.order=s,this.children=new Map}}class E extends v{static create(e,t,i){const o=new n.Qi(i),a=new E(t.uri),l=e.ordered(t),c=l.map(((e,i)=>{const s=v.findId(`provider_${i}`,a),n=new b(s,a,e.displayName??"Unknown Outline Provider",i);return Promise.resolve(e.provideDocumentSymbols(t,o.token)).then((e=>{for(const t of e||[])E._makeOutlineElement(t,n);return n}),(e=>((0,r.M_)(e),n))).then((e=>{v.empty(e)?e.remove():a._groups.set(s,e)}))})),h=e.onDidChange((()=>{const i=e.ordered(t);(0,s.aI)(i,l)||o.cancel()}));return Promise.all(c).then((()=>o.token.isCancellationRequested&&!i.isCancellationRequested?E.create(e,t,i):a._compact())).finally((()=>{o.dispose(),h.dispose(),o.dispose()}))}static _makeOutlineElement(e,t){const i=v.findId(e,t),s=new C(i,t,e);if(e.children)for(const n of e.children)E._makeOutlineElement(n,s);t.children.set(s.id,s)}constructor(e){super(),this.uri=e,this.id="root",this.parent=void 0,this._groups=new Map,this.children=new Map,this.id="root",this.parent=void 0}_compact(){let e=0;for(const[t,i]of this._groups)0===i.children.size?this._groups.delete(t):e+=1;if(1!==e)this.children=this._groups;else{const e=o.f.first(this._groups.values());for(const[,t]of e.children)t.parent=this,this.children.set(t.id,t)}return this}getTopLevelSymbols(){const e=[];for(const t of this.children.values())t instanceof C?e.push(t.symbol):e.push(...o.f.map(t.children.values(),(e=>e.symbol)));return e.sort(((e,t)=>c.Q.compareRangesUsingStarts(e.range,t.range)))}asListOfDocumentSymbols(){const e=this.getTopLevelSymbols(),t=[];return E._flattenDocumentSymbols(t,e,""),t.sort(((e,t)=>l.y.compare(c.Q.getStartPosition(e.range),c.Q.getStartPosition(t.range))||l.y.compare(c.Q.getEndPosition(t.range),c.Q.getEndPosition(e.range))))}static _flattenDocumentSymbols(e,t,i){for(const s of t)e.push({kind:s.kind,tags:s.tags,name:s.name,detail:s.detail,containerName:s.containerName||i,range:s.range,selectionRange:s.selectionRange,children:void 0}),s.children&&E._flattenDocumentSymbols(e,s.children,s.name)}}const S=(0,d.u1)("IOutlineModelService");let y=class{constructor(e,t,i){this._languageFeaturesService=e,this._disposables=new p.Cm,this._cache=new a.qK(10,.7),this._debounceInformation=t.for(e.documentSymbolProvider,"DocumentSymbols",{min:350}),this._disposables.add(i.onModelRemoved((e=>{this._cache.delete(e.id)})))}dispose(){this._disposables.dispose()}async getOrCreate(e,t){const i=this._languageFeaturesService.documentSymbolProvider,r=i.ordered(e);let o=this._cache.get(e.id);if(!o||o.versionId!==e.getVersionId()||!(0,s.aI)(o.provider,r)){const t=new n.Qi;o={versionId:e.getVersionId(),provider:r,promiseCnt:0,source:t,promise:E.create(i,e,t.token),model:void 0},this._cache.set(e.id,o);const s=Date.now();o.promise.then((t=>{o.model=t,this._debounceInformation.update(e,Date.now()-s)})).catch((t=>{this._cache.delete(e.id)}))}if(o.model)return o.model;o.promiseCnt+=1;const a=t.onCancellationRequested((()=>{0===--o.promiseCnt&&(o.source.cancel(),this._cache.delete(e.id))}));try{return await o.promise}finally{a.dispose()}}};y=f([_(0,m.ILanguageFeaturesService),_(1,h.ILanguageFeatureDebounceService),_(2,g.IModelService)],y),(0,u.v)(S,y,1)},63867:(e,t,i)=>{"use strict";var s=i(8995),n=i(31450),r=i(60002),o=i(72466),a=i(55433),l=i(90208),c=i(78209);(0,n.HW)(a.Rj.ID,a.Rj,0),(0,o.x)(l.L9),(0,n.E_)(new class extends n.DX{constructor(){super({id:a.qs,precondition:a.lr,kbOpts:{weight:100,primary:2137}})}runEditorCommand(e,t){return a.Rj.get(t)?.changePasteType()}}),(0,n.E_)(new class extends n.DX{constructor(){super({id:"editor.hidePasteWidget",precondition:a.lr,kbOpts:{weight:100,primary:9}})}runEditorCommand(e,t){a.Rj.get(t)?.clearWidgets()}}),(0,n.Fl)(class e extends n.ks{static{this.argsSchema={type:"object",properties:{kind:{type:"string",description:c.kg("pasteAs.kind","The kind of the paste edit to try applying. If not provided or there are multiple edits for this kind, the editor will show a picker.")}}}}constructor(){super({id:"editor.action.pasteAs",label:c.kg("pasteAs","Paste As..."),alias:"Paste As...",precondition:r.R.writable,metadata:{description:"Paste as",args:[{name:"args",schema:e.argsSchema}]}})}run(e,t,i){let n="string"===typeof i?.kind?i.kind:void 0;return!n&&i&&(n="string"===typeof i.id?i.id:void 0),a.Rj.get(t)?.pasteAs(n?new s.k(n):void 0)}}),(0,n.Fl)(class extends n.ks{constructor(){super({id:"editor.action.pasteAsText",label:c.kg("pasteAsText","Paste as Text"),alias:"Paste as Text",precondition:r.R.writable})}run(e,t){return a.Rj.get(t)?.pasteAs({providerId:l.LR.id})}})},55433:(e,t,i)=>{"use strict";i.d(t,{Rj:()=>U,lr:()=>P,qs:()=>M});var s,n=i(8597),r=i(25890),o=i(90766),a=i(18447),l=i(17799),c=i(8995),h=i(5662),d=i(44320),u=i(98067),g=i(58255),p=i(68792),m=i(85411),f=i(80537),_=i(36677),v=i(62083),C=i(56942),b=i(90208),E=i(85541),S=i(50868),y=i(9948),w=i(99645),L=i(78209),R=i(54770),T=i(32848),x=i(63591),k=i(73823),A=i(51467),N=i(56687),I=i(64383),O=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},D=function(e,t){return function(i,s){t(i,s,e)}};const M="editor.changePasteType",P=new T.N1("pasteWidgetVisible",!1,(0,L.kg)("pasteWidgetVisible","Whether the paste widget is showing")),F="application/vnd.code.copyMetadata";let U=class extends h.jG{static{s=this}static{this.ID="editor.contrib.copyPasteActionController"}static get(e){return e.getContribution(s.ID)}constructor(e,t,i,s,r,o,a){super(),this._bulkEditService=i,this._clipboardService=s,this._languageFeaturesService=r,this._quickInputService=o,this._progressService=a,this._editor=e;const l=e.getContainerDomNode();this._register((0,n.ko)(l,"copy",(e=>this.handleCopy(e)))),this._register((0,n.ko)(l,"cut",(e=>this.handleCopy(e)))),this._register((0,n.ko)(l,"paste",(e=>this.handlePaste(e)),!0)),this._pasteProgressManager=this._register(new y.I("pasteIntoEditor",e,t)),this._postPasteWidgetManager=this._register(t.createInstance(N.G,"pasteIntoEditor",e,P,{id:M,label:(0,L.kg)("postPasteWidgetTitle","Show paste options...")}))}changePasteType(){this._postPasteWidgetManager.tryShowSelector()}pasteAs(e){this._editor.focus();try{this._pasteAsActionContext={preferred:e},(0,n.a)().execCommand("paste")}finally{this._pasteAsActionContext=void 0}}clearWidgets(){this._postPasteWidgetManager.clear()}isPasteAsEnabled(){return this._editor.getOption(85).enabled}async finishedPaste(){await this._currentPasteOperation}handleCopy(e){if(!this._editor.hasTextFocus())return;if(this._clipboardService.clearInternalState?.(),!e.clipboardData||!this.isPasteAsEnabled())return;const t=this._editor.getModel(),i=this._editor.getSelections();if(!t||!i?.length)return;const n=this._editor.getOption(37);let a=i;const l=1===i.length&&i[0].isEmpty();if(l){if(!n)return;a=[new _.Q(a[0].startLineNumber,1,a[0].startLineNumber,1+t.getLineLength(a[0].startLineNumber))]}const c=this._editor._getViewModel()?.getPlainTextToCopy(i,n,u.uF),h={multicursorText:Array.isArray(c)?c:null,pasteOnNewLine:l,mode:null},d=this._languageFeaturesService.documentPasteEditProvider.ordered(t).filter((e=>!!e.prepareDocumentPaste));if(!d.length)return void this.setCopyMetadata(e.clipboardData,{defaultPastePayload:h});const p=(0,m.q)(e.clipboardData),f=d.flatMap((e=>e.copyMimeTypes??[])),v=(0,g.b)();this.setCopyMetadata(e.clipboardData,{id:v,providerCopyMimeTypes:f,defaultPastePayload:h});const C=(0,o.SS)((async e=>{const i=(0,r.Yc)(await Promise.all(d.map((async i=>{try{return await i.prepareDocumentPaste(t,a,p,e)}catch(s){return void console.error(s)}}))));i.reverse();for(const t of i)for(const[e,i]of t)p.replace(e,i);return p}));s._currentCopyOperation?.dataTransferPromise.cancel(),s._currentCopyOperation={handle:v,dataTransferPromise:C}}async handlePaste(e){if(!e.clipboardData||!this._editor.hasTextFocus())return;w.k.get(this._editor)?.closeMessage(),this._currentPasteOperation?.cancel(),this._currentPasteOperation=void 0;const t=this._editor.getModel(),i=this._editor.getSelections();if(!i?.length||!t)return;if(this._editor.getOption(92)||!this.isPasteAsEnabled()&&!this._pasteAsActionContext)return;const s=this.fetchCopyMetadata(e),n=(0,m.l)(e.clipboardData);n.delete(F);const r=[...e.clipboardData.types,...s?.providerCopyMimeTypes??[],d.K.uriList],o=this._languageFeaturesService.documentPasteEditProvider.ordered(t).filter((e=>{const t=this._pasteAsActionContext?.preferred;return!(t&&e.providedPasteEditKinds&&!this.providerMatchesPreference(e,t))&&e.pasteMimeTypes?.some((e=>(0,l.Y)(e,r)))}));o.length?(e.preventDefault(),e.stopImmediatePropagation(),this._pasteAsActionContext?this.showPasteAsPick(this._pasteAsActionContext.preferred,o,i,n,s):this.doPasteInline(o,i,n,s,e)):this._pasteAsActionContext?.preferred&&this.showPasteAsNoEditMessage(i,this._pasteAsActionContext.preferred)}showPasteAsNoEditMessage(e,t){w.k.get(this._editor)?.showMessage((0,L.kg)("pasteAsError","No paste edits for '{0}' found",t instanceof c.k?t.value:t.providerId),e[0].getStartPosition())}doPasteInline(e,t,i,s,n){const r=this._editor;if(!r.hasModel())return;const l=new S.gI(r,3,void 0),c=(0,o.SS)((async r=>{const d=this._editor;if(!d.hasModel())return;const u=d.getModel(),g=new h.Cm,p=g.add(new a.Qi(r));g.add(l.token.onCancellationRequested((()=>p.cancel())));const m=p.token;try{if(await this.mergeInDataFromCopy(i,s,m),m.isCancellationRequested)return;const r=e.filter((e=>this.isSupportedPasteProvider(e,i)));if(!r.length||1===r.length&&r[0]instanceof b.LR)return this.applyDefaultPasteHandler(i,s,m,n);const a={triggerKind:v.FX.Automatic},l=await this.getPasteEdits(r,i,u,t,a,m);if(g.add(l),m.isCancellationRequested)return;if(1===l.edits.length&&l.edits[0].provider instanceof b.LR)return this.applyDefaultPasteHandler(i,s,m,n);if(l.edits.length){const e="afterPaste"===d.getOption(85).showPasteSelector;return this._postPasteWidgetManager.applyEditAndShowIfNeeded(t,{activeEditIndex:0,allEdits:l.edits},e,((e,i)=>new Promise(((s,n)=>{(async()=>{try{const r=e.provider.resolveDocumentPasteEdit?.(e,i),a=new o.Zv,l=r&&await this._pasteProgressManager.showWhile(t[0].getEndPosition(),(0,L.kg)("resolveProcess","Resolving paste edit. Click to cancel"),Promise.race([a.p,r]),{cancel:()=>(a.cancel(),n(new I.AL))},0);return l&&(e.additionalEdit=l.additionalEdit),s(e)}catch(r){return n(r)}})()}))),m)}await this.applyDefaultPasteHandler(i,s,m,n)}finally{g.dispose(),this._currentPasteOperation===c&&(this._currentPasteOperation=void 0)}}));this._pasteProgressManager.showWhile(t[0].getEndPosition(),(0,L.kg)("pasteIntoEditorProgress","Running paste handlers. Click to cancel and do basic paste"),c,{cancel:async()=>{try{if(c.cancel(),l.token.isCancellationRequested)return;await this.applyDefaultPasteHandler(i,s,l.token,n)}finally{l.dispose()}}}).then((()=>{l.dispose()})),this._currentPasteOperation=c}showPasteAsPick(e,t,i,s,n){const r=(0,o.SS)((async o=>{const a=this._editor;if(!a.hasModel())return;const l=a.getModel(),d=new h.Cm,u=d.add(new S.gI(a,3,void 0,o));try{if(await this.mergeInDataFromCopy(s,n,u.token),u.token.isCancellationRequested)return;let r=t.filter((t=>this.isSupportedPasteProvider(t,s,e)));e&&(r=r.filter((t=>this.providerMatchesPreference(t,e))));const o={triggerKind:v.FX.PasteAs,only:e&&e instanceof c.k?e:void 0};let a,h=d.add(await this.getPasteEdits(r,s,l,i,o,u.token));if(u.token.isCancellationRequested)return;if(e&&(h={edits:h.edits.filter((t=>e instanceof c.k?e.contains(t.kind):e.providerId===t.provider.id)),dispose:h.dispose}),!h.edits.length)return void(o.only&&this.showPasteAsNoEditMessage(i,o.only));if(e)a=h.edits.at(0);else{const e=await this._quickInputService.pick(h.edits.map((e=>({label:e.title,description:e.kind?.value,edit:e}))),{placeHolder:(0,L.kg)("pasteAsPickerPlaceholder","Select Paste Action")});a=e?.edit}if(!a)return;const g=(0,E.v)(l.uri,i,a);await this._bulkEditService.apply(g,{editor:this._editor})}finally{d.dispose(),this._currentPasteOperation===r&&(this._currentPasteOperation=void 0)}}));this._progressService.withProgress({location:10,title:(0,L.kg)("pasteAsProgress","Running paste handlers")},(()=>r))}setCopyMetadata(e,t){e.setData(F,JSON.stringify(t))}fetchCopyMetadata(e){if(!e.clipboardData)return;const t=e.clipboardData.getData(F);if(t)try{return JSON.parse(t)}catch{return}const[i,s]=p.Mz.getTextData(e.clipboardData);return s?{defaultPastePayload:{mode:s.mode,multicursorText:s.multicursorText??null,pasteOnNewLine:!!s.isFromEmptySelection}}:void 0}async mergeInDataFromCopy(e,t,i){if(t?.id&&s._currentCopyOperation?.handle===t.id){const t=await s._currentCopyOperation.dataTransferPromise;if(i.isCancellationRequested)return;for(const[i,s]of t)e.replace(i,s)}if(!e.has(d.K.uriList)){const t=await this._clipboardService.readResources();if(i.isCancellationRequested)return;t.length&&e.append(d.K.uriList,(0,l.gf)(l.jt.create(t)))}}async getPasteEdits(e,t,i,s,n,a){const l=new h.Cm,c=await(0,o.PK)(Promise.all(e.map((async e=>{try{const r=await(e.provideDocumentPasteEdits?.(i,s,t,n,a));return r&&l.add(r),r?.edits?.map((t=>({...t,provider:e})))}catch(r){return void((0,I.MB)(r)||console.error(r))}}))),a),d=(0,r.Yc)(c??[]).flat().filter((e=>!n.only||n.only.contains(e.kind)));return{edits:(0,E.H)(d),dispose:()=>l.dispose()}}async applyDefaultPasteHandler(e,t,i,s){const n=e.get(d.K.text)??e.get("text"),r=await(n?.asString())??"";if(i.isCancellationRequested)return;const o={clipboardEvent:s,text:r,pasteOnNewLine:t?.defaultPastePayload.pasteOnNewLine??!1,multicursorText:t?.defaultPastePayload.multicursorText??null,mode:null};this._editor.trigger("keyboard","paste",o)}isSupportedPasteProvider(e,t,i){return!!e.pasteMimeTypes?.some((e=>t.matches(e)))&&(!i||this.providerMatchesPreference(e,i))}providerMatchesPreference(e,t){return t instanceof c.k?!e.providedPasteEditKinds||e.providedPasteEditKinds.some((e=>t.contains(e))):e.id===t.providerId}};U=s=O([D(1,x._Y),D(2,f.nu),D(3,R.h),D(4,C.ILanguageFeaturesService),D(5,A.GK),D(6,k.G5)],U)},90208:(e,t,i)=>{"use strict";i.d(t,{L9:()=>w,LR:()=>v,ZR:()=>y});var s=i(25890),n=i(17799),r=i(8995),o=i(5662),a=i(44320),l=i(36456),c=i(89403),h=i(79400),d=i(62083),u=i(56942),g=i(78209),p=i(37227),m=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},f=function(e,t){return function(i,s){t(i,s,e)}};class _{async provideDocumentPasteEdits(e,t,i,s,n){const r=await this.getEdit(i,n);if(r)return{edits:[{insertText:r.insertText,title:r.title,kind:r.kind,handledMimeType:r.handledMimeType,yieldTo:r.yieldTo}],dispose(){}}}async provideDocumentDropEdits(e,t,i,s){const n=await this.getEdit(i,s);if(n)return{edits:[{insertText:n.insertText,title:n.title,kind:n.kind,handledMimeType:n.handledMimeType,yieldTo:n.yieldTo}],dispose(){}}}}class v extends _{constructor(){super(...arguments),this.kind=v.kind,this.dropMimeTypes=[a.K.text],this.pasteMimeTypes=[a.K.text]}static{this.id="text"}static{this.kind=new r.k("text.plain")}async getEdit(e,t){const i=e.get(a.K.text);if(!i)return;if(e.has(a.K.uriList))return;const s=await i.asString();return{handledMimeType:a.K.text,title:(0,g.kg)("text.label","Insert Plain Text"),insertText:s,kind:this.kind}}}class C extends _{constructor(){super(...arguments),this.kind=new r.k("uri.absolute"),this.dropMimeTypes=[a.K.uriList],this.pasteMimeTypes=[a.K.uriList]}async getEdit(e,t){const i=await S(e);if(!i.length||t.isCancellationRequested)return;let s=0;const n=i.map((({uri:e,originalText:t})=>e.scheme===l.ny.file?e.fsPath:(s++,t))).join(" ");let r;return r=s>0?i.length>1?(0,g.kg)("defaultDropProvider.uriList.uris","Insert Uris"):(0,g.kg)("defaultDropProvider.uriList.uri","Insert Uri"):i.length>1?(0,g.kg)("defaultDropProvider.uriList.paths","Insert Paths"):(0,g.kg)("defaultDropProvider.uriList.path","Insert Path"),{handledMimeType:a.K.uriList,insertText:n,title:r,kind:this.kind}}}let b=class extends _{constructor(e){super(),this._workspaceContextService=e,this.kind=new r.k("uri.relative"),this.dropMimeTypes=[a.K.uriList],this.pasteMimeTypes=[a.K.uriList]}async getEdit(e,t){const i=await S(e);if(!i.length||t.isCancellationRequested)return;const n=(0,s.Yc)(i.map((({uri:e})=>{const t=this._workspaceContextService.getWorkspaceFolder(e);return t?(0,c.iZ)(t.uri,e):void 0})));return n.length?{handledMimeType:a.K.uriList,insertText:n.join(" "),title:i.length>1?(0,g.kg)("defaultDropProvider.uriList.relativePaths","Insert Relative Paths"):(0,g.kg)("defaultDropProvider.uriList.relativePath","Insert Relative Path"),kind:this.kind}:void 0}};b=m([f(0,p.VR)],b);class E{constructor(){this.kind=new r.k("html"),this.pasteMimeTypes=["text/html"],this._yieldTo=[{mimeType:a.K.text}]}async provideDocumentPasteEdits(e,t,i,s,n){if(s.triggerKind!==d.FX.PasteAs&&!s.only?.contains(this.kind))return;const r=i.get("text/html"),o=await(r?.asString());return o&&!n.isCancellationRequested?{dispose(){},edits:[{insertText:o,yieldTo:this._yieldTo,title:(0,g.kg)("pasteHtmlLabel","Insert HTML"),kind:this.kind}]}:void 0}}async function S(e){const t=e.get(a.K.uriList);if(!t)return[];const i=await t.asString(),s=[];for(const r of n.jt.parse(i))try{s.push({uri:h.r.parse(r),originalText:r})}catch{}return s}let y=class extends o.jG{constructor(e,t){super(),this._register(e.documentDropEditProvider.register("*",new v)),this._register(e.documentDropEditProvider.register("*",new C)),this._register(e.documentDropEditProvider.register("*",new b(t)))}};y=m([f(0,u.ILanguageFeaturesService),f(1,p.VR)],y);let w=class extends o.jG{constructor(e,t){super(),this._register(e.documentPasteEditProvider.register("*",new v)),this._register(e.documentPasteEditProvider.register("*",new C)),this._register(e.documentPasteEditProvider.register("*",new b(t))),this._register(e.documentPasteEditProvider.register("*",new E))}};w=m([f(0,u.ILanguageFeaturesService),f(1,p.VR)],w)},61731:(e,t,i)=>{"use strict";var s,n=i(31450),r=i(94371),o=i(72466),a=i(90208),l=i(78209),c=i(1646),h=i(46359),d=i(25890),u=i(90766),g=i(17799),p=i(8995),m=i(5662),f=i(85411),_=i(36677),v=i(56942),C=i(36723),b=i(29100),E=i(50868),S=i(9948),y=i(84001),w=i(32848),L=i(61292),R=i(63591),T=i(85541),x=i(56687),k=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},A=function(e,t){return function(i,s){t(i,s,e)}};const N="editor.experimental.dropIntoEditor.defaultProvider",I="editor.changeDropType",O=new w.N1("dropWidgetVisible",!1,(0,l.kg)("dropWidgetVisible","Whether the drop widget is showing"));let D=class extends m.jG{static{s=this}static{this.ID="editor.contrib.dropIntoEditorController"}static get(e){return e.getContribution(s.ID)}constructor(e,t,i,s,n){super(),this._configService=i,this._languageFeaturesService=s,this._treeViewsDragAndDropService=n,this.treeItemsTransfer=L.PD.getInstance(),this._dropProgressManager=this._register(t.createInstance(S.I,"dropIntoEditor",e)),this._postDropWidgetManager=this._register(t.createInstance(x.G,"dropIntoEditor",e,O,{id:I,label:(0,l.kg)("postDropWidgetTitle","Show drop options...")})),this._register(e.onDropIntoEditor((t=>this.onDropIntoEditor(e,t.position,t.event))))}clearWidgets(){this._postDropWidgetManager.clear()}changeDropType(){this._postDropWidgetManager.tryShowSelector()}async onDropIntoEditor(e,t,i){if(!i.dataTransfer||!e.hasModel())return;this._currentOperation?.cancel(),e.focus(),e.setPosition(t);const s=(0,u.SS)((async n=>{const r=new m.Cm,o=r.add(new E.gI(e,1,void 0,n));try{const s=await this.extractDataTransferData(i);if(0===s.size||o.token.isCancellationRequested)return;const a=e.getModel();if(!a)return;const l=this._languageFeaturesService.documentDropEditProvider.ordered(a).filter((e=>!e.dropMimeTypes||e.dropMimeTypes.some((e=>s.matches(e))))),c=r.add(await this.getDropEdits(l,a,t,s,o));if(o.token.isCancellationRequested)return;if(c.edits.length){const i=this.getInitialActiveEditIndex(a,c.edits),s="afterDrop"===e.getOption(36).showDropSelector;await this._postDropWidgetManager.applyEditAndShowIfNeeded([_.Q.fromPositions(t)],{activeEditIndex:i,allEdits:c.edits},s,(async e=>e),n)}}finally{r.dispose(),this._currentOperation===s&&(this._currentOperation=void 0)}}));this._dropProgressManager.showWhile(t,(0,l.kg)("dropIntoEditorProgress","Running drop handlers. Click to cancel"),s,{cancel:()=>s.cancel()}),this._currentOperation=s}async getDropEdits(e,t,i,s,n){const r=new m.Cm,o=await(0,u.PK)(Promise.all(e.map((async e=>{try{const o=await e.provideDocumentDropEdits(t,i,s,n.token);return o&&r.add(o),o?.edits.map((t=>({...t,providerId:e.id})))}catch(o){console.error(o)}}))),n.token),a=(0,d.Yc)(o??[]).flat();return{edits:(0,T.H)(a),dispose:()=>r.dispose()}}getInitialActiveEditIndex(e,t){const i=this._configService.getValue(N,{resource:e.uri});for(const[s,n]of Object.entries(i)){const e=new p.k(n),i=t.findIndex((t=>e.value===t.providerId&&t.handledMimeType&&(0,g.Y)(s,[t.handledMimeType])));if(i>=0)return i}return 0}async extractDataTransferData(e){if(!e.dataTransfer)return new g.Vq;const t=(0,f.l)(e.dataTransfer);if(this.treeItemsTransfer.hasData(C.DraggedTreeItemsIdentifier.prototype)){const e=this.treeItemsTransfer.getData(C.DraggedTreeItemsIdentifier.prototype);if(Array.isArray(e))for(const i of e){const e=await this._treeViewsDragAndDropService.removeDragOperationTransfer(i.identifier);if(e)for(const[i,s]of e)t.replace(i,s)}}return t}};D=s=k([A(1,R._Y),A(2,y.pG),A(3,v.ILanguageFeaturesService),A(4,b.ITreeViewsDnDService)],D),(0,n.HW)(D.ID,D,2),(0,o.x)(a.ZR),(0,n.E_)(new class extends n.DX{constructor(){super({id:I,precondition:O,kbOpts:{weight:100,primary:2137}})}runEditorCommand(e,t,i){D.get(t)?.changeDropType()}}),(0,n.E_)(new class extends n.DX{constructor(){super({id:"editor.hideDropWidget",precondition:O,kbOpts:{weight:100,primary:9}})}runEditorCommand(e,t,i){D.get(t)?.clearWidgets()}}),h.O.as(c.Fd.Configuration).registerConfiguration({...r.JJ,properties:{[N]:{type:"object",scope:5,description:l.kg("defaultProviderDescription","Configures the default drop provider to use for content of a given mime type."),default:{},additionalProperties:{type:"string"}}}})},85541:(e,t,i)=>{"use strict";i.d(t,{H:()=>o,v:()=>r});var s=i(80537),n=i(29319);function r(e,t,i){return("string"===typeof i.insertText?""===i.insertText:""===i.insertText.snippet)?{edits:i.additionalEdit?.edits??[]}:{edits:[...t.map((t=>new s.cw(e,{range:t,text:"string"===typeof i.insertText?n.fr.escape(i.insertText)+"$0":i.insertText.snippet,insertAsSnippet:!0}))),...i.additionalEdit?.edits??[]]}}function o(e){function t(e,t){return"mimeType"in e?e.mimeType===t.handledMimeType:!!t.kind&&e.kind.contains(t.kind)}const i=new Map;for(const r of e)for(const s of r.yieldTo??[])for(const n of e)if(n!==r&&t(s,n)){let e=i.get(r);e||(e=[],i.set(r,e)),e.push(n)}if(!i.size)return Array.from(e);const s=new Set,n=[];return function e(t){if(!t.length)return[];const r=t[0];if(n.includes(r))return console.warn("Yield to cycle detected",r),t;if(s.has(r))return e(t.slice(1));let o=[];const a=i.get(r);return a&&(n.push(r),o=e(a),n.pop()),s.add(r),[...o,r,...e(t.slice(1))]}(Array.from(e))}},56687:(e,t,i)=>{"use strict";i.d(t,{G:()=>S});var s,n=i(8597),r=i(62890),o=i(36921),a=i(70125),l=i(64383),c=i(41234),h=i(5662),d=i(80537),u=i(85541),g=i(78209),p=i(32848),m=i(47508),f=i(63591),_=i(98031),v=i(58591),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},b=function(e,t){return function(i,s){t(i,s,e)}};let E=class extends h.jG{static{s=this}static{this.baseId="editor.widget.postEditWidget"}constructor(e,t,i,s,n,r,o,a,l,d){super(),this.typeId=e,this.editor=t,this.showCommand=s,this.range=n,this.edits=r,this.onSelectNewEdit=o,this._contextMenuService=a,this._keybindingService=d,this.allowEditorOverflow=!0,this.suppressMouseDown=!0,this.create(),this.visibleContext=i.bindTo(l),this.visibleContext.set(!0),this._register((0,h.s)((()=>this.visibleContext.reset()))),this.editor.addContentWidget(this),this.editor.layoutContentWidget(this),this._register((0,h.s)((()=>this.editor.removeContentWidget(this)))),this._register(this.editor.onDidChangeCursorPosition((e=>{n.containsPosition(e.position)||this.dispose()}))),this._register(c.Jh.runAndSubscribe(d.onDidUpdateKeybindings,(()=>{this._updateButtonTitle()})))}_updateButtonTitle(){const e=this._keybindingService.lookupKeybinding(this.showCommand.id)?.getLabel();this.button.element.title=this.showCommand.label+(e?` (${e})`:"")}create(){this.domNode=n.$(".post-edit-widget"),this.button=this._register(new r.$(this.domNode,{supportIcons:!0})),this.button.label="$(insert)",this._register(n.ko(this.domNode,n.Bx.CLICK,(()=>this.showSelector())))}getId(){return s.baseId+"."+this.typeId}getDomNode(){return this.domNode}getPosition(){return{position:this.range.getEndPosition(),preference:[2]}}showSelector(){this._contextMenuService.showContextMenu({getAnchor:()=>{const e=n.BK(this.button.element);return{x:e.left+e.width,y:e.top+e.height}},getActions:()=>this.edits.allEdits.map(((e,t)=>(0,o.ih)({id:"",label:e.title,checked:t===this.edits.activeEditIndex,run:()=>{if(t!==this.edits.activeEditIndex)return this.onSelectNewEdit(t)}})))})}};E=s=C([b(7,m.Z),b(8,p.fN),b(9,_.b)],E);let S=class extends h.jG{constructor(e,t,i,s,n,r,o){super(),this._id=e,this._editor=t,this._visibleContext=i,this._showCommand=s,this._instantiationService=n,this._bulkEditService=r,this._notificationService=o,this._currentWidget=this._register(new h.HE),this._register(c.Jh.any(t.onDidChangeModel,t.onDidChangeModelContent)((()=>this.clear())))}async applyEditAndShowIfNeeded(e,t,i,s,n){const r=this._editor.getModel();if(!r||!e.length)return;const o=t.allEdits.at(t.activeEditIndex);if(!o)return;const c=async r=>{const o=this._editor.getModel();o&&(await o.undo(),this.applyEditAndShowIfNeeded(e,{activeEditIndex:r,allEdits:t.allEdits},i,s,n))},h=(s,n)=>{(0,l.MB)(s)||(this._notificationService.error(n),i&&this.show(e[0],t,c))};let d;try{d=await s(o,n)}catch(C){return h(C,(0,g.kg)("resolveError","Error resolving edit '{0}':\n{1}",o.title,(0,a.r)(C)))}if(n.isCancellationRequested)return;const p=(0,u.v)(r.uri,e,d),m=e[0],f=r.deltaDecorations([],[{range:m,options:{description:"paste-line-suffix",stickiness:0}}]);let _,v;this._editor.focus();try{_=await this._bulkEditService.apply(p,{editor:this._editor,token:n}),v=r.getDecorationRange(f[0])}catch(C){return h(C,(0,g.kg)("applyError","Error applying edit '{0}':\n{1}",o.title,(0,a.r)(C)))}finally{r.deltaDecorations(f,[])}n.isCancellationRequested||i&&_.isApplied&&t.allEdits.length>1&&this.show(v??m,t,c)}show(e,t,i){this.clear(),this._editor.hasModel()&&(this._currentWidget.value=this._instantiationService.createInstance(E,this._id,this._editor,this._visibleContext,this._showCommand,e,t,i))}clear(){this._currentWidget.clear()}tryShowSelector(){this._currentWidget.value?.showSelector()}};S=C([b(4,f._Y),b(5,d.nu),b(6,v.Ot)],S)},50868:(e,t,i)=>{"use strict";i.d(t,{$t:()=>f,gI:()=>_,ER:()=>v});var s=i(91508),n=i(36677),r=i(18447),o=i(5662),a=i(31450),l=i(32848),c=i(58925),h=i(63591),d=i(14718),u=i(78209);const g=(0,h.u1)("IEditorCancelService"),p=new l.N1("cancellableOperation",!1,(0,u.kg)("cancellableOperation","Whether the editor runs a cancellable operation, e.g. like 'Peek References'"));(0,d.v)(g,class{constructor(){this._tokens=new WeakMap}add(e,t){let i,s=this._tokens.get(e);return s||(s=e.invokeWithinContext((e=>({key:p.bindTo(e.get(l.fN)),tokens:new c.w}))),this._tokens.set(e,s)),s.key.set(!0),i=s.tokens.push(t),()=>{i&&(i(),s.key.set(!s.tokens.isEmpty()),i=void 0)}}cancel(e){const t=this._tokens.get(e);if(!t)return;const i=t.tokens.pop();i&&(i.cancel(),t.key.set(!t.tokens.isEmpty()))}},1);class m extends r.Qi{constructor(e,t){super(t),this.editor=e,this._unregister=e.invokeWithinContext((t=>t.get(g).add(e,this)))}dispose(){this._unregister(),super.dispose()}}(0,a.E_)(new class extends a.DX{constructor(){super({id:"editor.cancelOperation",kbOpts:{weight:100,primary:9},precondition:p})}runEditorCommand(e,t){e.get(g).cancel(t)}});class f{constructor(e,t){if(this.flags=t,0!==(1&this.flags)){const t=e.getModel();this.modelVersionId=t?s.GP("{0}#{1}",t.uri.toString(),t.getVersionId()):null}else this.modelVersionId=null;0!==(4&this.flags)?this.position=e.getPosition():this.position=null,0!==(2&this.flags)?this.selection=e.getSelection():this.selection=null,0!==(8&this.flags)?(this.scrollLeft=e.getScrollLeft(),this.scrollTop=e.getScrollTop()):(this.scrollLeft=-1,this.scrollTop=-1)}_equals(e){if(!(e instanceof f))return!1;const t=e;return this.modelVersionId===t.modelVersionId&&(this.scrollLeft===t.scrollLeft&&this.scrollTop===t.scrollTop&&(!(!this.position&&t.position||this.position&&!t.position||this.position&&t.position&&!this.position.equals(t.position))&&!(!this.selection&&t.selection||this.selection&&!t.selection||this.selection&&t.selection&&!this.selection.equalsRange(t.selection))))}validate(e){return this._equals(new f(e,this.flags))}}class _ extends m{constructor(e,t,i,s){super(e,s),this._listener=new o.Cm,4&t&&this._listener.add(e.onDidChangeCursorPosition((e=>{i&&n.Q.containsPosition(i,e.position)||this.cancel()}))),2&t&&this._listener.add(e.onDidChangeCursorSelection((e=>{i&&n.Q.containsRange(i,e.selection)||this.cancel()}))),8&t&&this._listener.add(e.onDidScrollChange((e=>this.cancel()))),1&t&&(this._listener.add(e.onDidChangeModel((e=>this.cancel()))),this._listener.add(e.onDidChangeModelContent((e=>this.cancel()))))}dispose(){this._listener.dispose(),super.dispose()}}class v extends r.Qi{constructor(e,t){super(t),this._listener=e.onDidChangeContent((()=>this.cancel()))}dispose(){this._listener.dispose(),super.dispose()}}},34175:(e,t,i)=>{"use strict";i.d(t,{z0:()=>mt});var s=i(90766),n=i(5662),r=i(91508),o=i(31450),a=i(87119),l=i(60002),c=i(16223),h=i(46041),d=i(15092),u=i(83069),g=i(36677),p=i(75326),m=i(43264),f=i(87289),_=i(66261),v=i(47612);class C{constructor(e){this._editor=e,this._decorations=[],this._overviewRulerApproximateDecorations=[],this._findScopeDecorationIds=[],this._rangeHighlightDecorationId=null,this._highlightedDecorationId=null,this._startPosition=this._editor.getPosition()}dispose(){this._editor.removeDecorations(this._allDecorations()),this._decorations=[],this._overviewRulerApproximateDecorations=[],this._findScopeDecorationIds=[],this._rangeHighlightDecorationId=null,this._highlightedDecorationId=null}reset(){this._decorations=[],this._overviewRulerApproximateDecorations=[],this._findScopeDecorationIds=[],this._rangeHighlightDecorationId=null,this._highlightedDecorationId=null}getCount(){return this._decorations.length}getFindScope(){return this._findScopeDecorationIds[0]?this._editor.getModel().getDecorationRange(this._findScopeDecorationIds[0]):null}getFindScopes(){if(this._findScopeDecorationIds.length){const e=this._findScopeDecorationIds.map((e=>this._editor.getModel().getDecorationRange(e))).filter((e=>!!e));if(e.length)return e}return null}getStartPosition(){return this._startPosition}setStartPosition(e){this._startPosition=e,this.setCurrentFindMatch(null)}_getDecorationIndex(e){const t=this._decorations.indexOf(e);return t>=0?t+1:1}getDecorationRangeAt(e){const t=e{if(null!==this._highlightedDecorationId&&(e.changeDecorationOptions(this._highlightedDecorationId,C._FIND_MATCH_DECORATION),this._highlightedDecorationId=null),null!==t&&(this._highlightedDecorationId=t,e.changeDecorationOptions(this._highlightedDecorationId,C._CURRENT_FIND_MATCH_DECORATION)),null!==this._rangeHighlightDecorationId&&(e.removeDecoration(this._rangeHighlightDecorationId),this._rangeHighlightDecorationId=null),null!==t){let i=this._editor.getModel().getDecorationRange(t);if(i.startLineNumber!==i.endLineNumber&&1===i.endColumn){const e=i.endLineNumber-1,t=this._editor.getModel().getLineMaxColumn(e);i=new g.Q(i.startLineNumber,i.startColumn,e,t)}this._rangeHighlightDecorationId=e.addDecoration(i,C._RANGE_HIGHLIGHT_DECORATION)}})),i}set(e,t){this._editor.changeDecorations((i=>{let s=C._FIND_MATCH_DECORATION;const n=[];if(e.length>1e3){s=C._FIND_MATCH_NO_OVERVIEW_DECORATION;const t=this._editor.getModel().getLineCount(),i=this._editor.getLayoutInfo().height/t,r=Math.max(2,Math.ceil(3/i));let o=e[0].range.startLineNumber,a=e[0].range.endLineNumber;for(let s=1,l=e.length;s=t.startLineNumber?t.endLineNumber>a&&(a=t.endLineNumber):(n.push({range:new g.Q(o,1,a,1),options:C._FIND_MATCH_ONLY_OVERVIEW_DECORATION}),o=t.startLineNumber,a=t.endLineNumber)}n.push({range:new g.Q(o,1,a,1),options:C._FIND_MATCH_ONLY_OVERVIEW_DECORATION})}const r=new Array(e.length);for(let t=0,o=e.length;ti.removeDecoration(e))),this._findScopeDecorationIds=[]),t?.length&&(this._findScopeDecorationIds=t.map((e=>i.addDecoration(e,C._FIND_SCOPE_DECORATION))))}))}matchBeforePosition(e){if(0===this._decorations.length)return null;for(let t=this._decorations.length-1;t>=0;t--){const i=this._decorations[t],s=this._editor.getModel().getDecorationRange(i);if(s&&!(s.endLineNumber>e.lineNumber)){if(s.endLineNumbere.column))return s}}return this._editor.getModel().getDecorationRange(this._decorations[this._decorations.length-1])}matchAfterPosition(e){if(0===this._decorations.length)return null;for(let t=0,i=this._decorations.length;te.lineNumber)return s;if(!(s.startColumn0){const e=[];for(let t=0;tg.Q.compareRangesUsingStarts(e.range,t.range)));const i=[];let s=e[0];for(let t=1;t0?t[0].toUpperCase()+t.substr(1):e[0][0].toUpperCase()!==e[0][0]&&t.length>0?t[0].toLowerCase()+t.substr(1):t}return t}function S(e,t,i){return-1!==e[0].indexOf(i)&&-1!==t.indexOf(i)&&e[0].split(i).length===t.split(i).length}function y(e,t,i){const s=t.split(i),n=e[0].split(i);let r="";return s.forEach(((e,t)=>{r+=E([n[t]],e)+i})),r.slice(0,-1)}class w{constructor(e){this.staticValue=e,this.kind=0}}class L{constructor(e){this.pieces=e,this.kind=1}}class R{static fromStaticValue(e){return new R([T.staticValue(e)])}get hasReplacementPatterns(){return 1===this._state.kind}constructor(e){e&&0!==e.length?1===e.length&&null!==e[0].staticValue?this._state=new w(e[0].staticValue):this._state=new L(e):this._state=new w("")}buildReplaceString(e,t){if(0===this._state.kind)return t?E(e,this._state.staticValue):this._state.staticValue;let i="";for(let s=0,n=this._state.pieces.length;s0){const e=[],i=t.caseOps.length;let s=0;for(let r=0,o=n.length;r=i){e.push(n.slice(r));break}switch(t.caseOps[s]){case"U":e.push(n[r].toUpperCase());break;case"u":e.push(n[r].toUpperCase()),s++;break;case"L":e.push(n[r].toLowerCase());break;case"l":e.push(n[r].toLowerCase()),s++;break;default:e.push(n[r])}}n=e.join("")}i+=n}return i}static _substitute(e,t){if(null===t)return"";if(0===e)return t[0];let i="";for(;e>0;){if(e{if(this._editor.hasModel())return this.research(!1)}),100),this._toDispose.add(this._updateDecorationsScheduler),this._toDispose.add(this._editor.onDidChangeCursorPosition((e=>{3!==e.reason&&5!==e.reason&&6!==e.reason||this._decorations.setStartPosition(this._editor.getPosition())}))),this._ignoreModelContentChanged=!1,this._toDispose.add(this._editor.onDidChangeModelContent((e=>{this._ignoreModelContentChanged||(e.isFlush&&this._decorations.reset(),this._decorations.setStartPosition(this._editor.getPosition()),this._updateDecorationsScheduler.schedule())}))),this._toDispose.add(this._state.onFindReplaceStateChange((e=>this._onStateChanged(e)))),this.research(!1,this._state.searchScope)}dispose(){this._isDisposed=!0,(0,n.AS)(this._startSearchingTimer),this._toDispose.dispose()}_onStateChanged(e){if(!this._isDisposed&&this._editor.hasModel()&&(e.searchString||e.isReplaceRevealed||e.isRegex||e.wholeWord||e.matchCase||e.searchScope)){this._editor.getModel().isTooLargeForSyncing()?(this._startSearchingTimer.cancel(),this._startSearchingTimer.setIfNotSet((()=>{e.searchScope?this.research(e.moveCursor,this._state.searchScope):this.research(e.moveCursor)}),240)):e.searchScope?this.research(e.moveCursor,this._state.searchScope):this.research(e.moveCursor)}}static _getSearchRange(e,t){return t||e.getFullModelRange()}research(e,t){let i=null;"undefined"!==typeof t?null!==t&&(i=Array.isArray(t)?t:[t]):i=this._decorations.getFindScopes(),null!==i&&(i=i.map((e=>{if(e.startLineNumber!==e.endLineNumber){let t=e.endLineNumber;return 1===e.endColumn&&(t-=1),new g.Q(e.startLineNumber,1,t,this._editor.getModel().getLineMaxColumn(t))}return e})));const s=this._findMatches(i,!1,ie);this._decorations.set(s,i);const n=this._editor.getSelection();let r=this._decorations.getCurrentMatchesPosition(n);if(0===r&&s.length>0){const e=(0,h.hw)(s.map((e=>e.range)),(e=>g.Q.compareRangesUsingStarts(e,n)>=0));r=e>0?e-1+1:r}this._state.changeMatchInfo(r,this._decorations.getCount(),void 0),e&&this._editor.getOption(41).cursorMoveOnType&&this._moveToNextMatch(this._decorations.getStartPosition())}_hasMatches(){return this._state.matchesCount>0}_cannotFind(){if(!this._hasMatches()){const e=this._decorations.getFindScope();return e&&this._editor.revealRangeInCenterIfOutsideViewport(e,0),!0}return!1}_setCurrentFindMatch(e){const t=this._decorations.setCurrentFindMatch(e);this._state.changeMatchInfo(t,this._decorations.getCount(),e),this._editor.setSelection(e),this._editor.revealRangeInCenterIfOutsideViewport(e,0)}_prevSearchPosition(e){const t=this._state.isRegex&&(this._state.searchString.indexOf("^")>=0||this._state.searchString.indexOf("$")>=0);let{lineNumber:i,column:s}=e;const n=this._editor.getModel();return t||1===s?(1===i?i=n.getLineCount():i--,s=n.getLineMaxColumn(i)):s--,new u.y(i,s)}_moveToPrevMatch(e,t=!1){if(!this._state.canNavigateBack()){const t=this._decorations.matchAfterPosition(e);return void(t&&this._setCurrentFindMatch(t))}if(this._decorations.getCount()=0||this._state.searchString.indexOf("$")>=0);let{lineNumber:i,column:s}=e;const n=this._editor.getModel();return t||s===n.getLineMaxColumn(i)?(i===n.getLineCount()?i=1:i++,s=1):s++,new u.y(i,s)}_moveToNextMatch(e){if(!this._state.canNavigateForward()){const t=this._decorations.matchBeforePosition(e);return void(t&&this._setCurrentFindMatch(t))}if(this._decorations.getCount()=n)break;const r=e.charCodeAt(s);if(36===r){i.emitUnchanged(s-1),i.emitStatic("$",s+1);continue}if(48===r||38===r){i.emitUnchanged(s-1),i.emitMatchIndex(0,s+1,t),t.length=0;continue}if(49<=r&&r<=57){let o=r-48;if(s+1=n)break;const r=e.charCodeAt(s);switch(r){case 92:i.emitUnchanged(s-1),i.emitStatic("\\",s+1);break;case 110:i.emitUnchanged(s-1),i.emitStatic("\n",s+1);break;case 116:i.emitUnchanged(s-1),i.emitStatic("\t",s+1);break;case 117:case 85:case 108:case 76:i.emitUnchanged(s-1),i.emitStatic("",s+1),t.push(String.fromCharCode(r))}}}return i.finalize()}(this._state.replaceString):R.fromStaticValue(this._state.replaceString)}replace(){if(!this._hasMatches())return;const e=this._getReplacePattern(),t=this._editor.getSelection(),i=this._getNextMatch(t.getStartPosition(),!0,!1);if(i)if(t.equalsRange(i.range)){const s=e.buildReplaceString(i.matches,this._state.preserveCase),n=new d.iu(t,s);this._executeEditorCommand("replace",n),this._decorations.setStartPosition(new u.y(t.startLineNumber,t.startColumn+s.length)),this.research(!0)}else this._decorations.setStartPosition(this._editor.getPosition()),this._setCurrentFindMatch(i.range)}_findMatches(e,t,i){const s=(e||[null]).map((e=>se._getSearchRange(this._editor.getModel(),e)));return this._editor.getModel().findMatches(this._state.searchString,s,this._state.isRegex,this._state.matchCase,this._state.wholeWord?this._editor.getOption(132):null,t,i)}replaceAll(){if(!this._hasMatches())return;const e=this._decorations.getFindScopes();null===e&&this._state.matchesCount>=ie?this._largeReplaceAll():this._regularReplaceAll(e),this.research(!1)}_largeReplaceAll(){const e=new m.lt(this._state.searchString,this._state.isRegex,this._state.matchCase,this._state.wholeWord?this._editor.getOption(132):null).parseSearchRequest();if(!e)return;let t=e.regex;if(!t.multiline){let e="mu";t.ignoreCase&&(e+="i"),t.global&&(e+="g"),t=new RegExp(t.source,e)}const i=this._editor.getModel(),s=i.getValue(1),n=i.getFullModelRange(),r=this._getReplacePattern();let o;const a=this._state.preserveCase;o=r.hasReplacementPatterns||a?s.replace(t,(function(){return r.buildReplaceString(arguments,a)})):s.replace(t,r.buildReplaceString(null,a));const l=new d.ui(n,o,this._editor.getSelection());this._executeEditorCommand("replaceAll",l)}_regularReplaceAll(e){const t=this._getReplacePattern(),i=this._findMatches(e,t.hasReplacementPatterns||this._state.preserveCase,1073741824),s=[];for(let r=0,o=i.length;re.range)),s);this._executeEditorCommand("replaceAll",n)}selectAllMatches(){if(!this._hasMatches())return;const e=this._decorations.getFindScopes();let t=this._findMatches(e,!1,1073741824).map((e=>new p.L(e.range.startLineNumber,e.range.startColumn,e.range.endLineNumber,e.range.endColumn)));const i=this._editor.getSelection();for(let s=0,n=t.length;sthis._hide()),2e3)),this._isVisible=!1,this._editor=e,this._state=t,this._keybindingService=i,this._domNode=document.createElement("div"),this._domNode.className="findOptionsWidget",this._domNode.style.display="none",this._domNode.style.top="10px",this._domNode.style.zIndex="12",this._domNode.setAttribute("role","presentation"),this._domNode.setAttribute("aria-hidden","true");const n={inputActiveOptionBorder:(0,_.GuP)(_.uNK),inputActiveOptionForeground:(0,_.GuP)(_.$$0),inputActiveOptionBackground:(0,_.GuP)(_.c1f)},r=this._register((0,ae.bW)());this.caseSensitive=this._register(new re.bc({appendTitle:this._keybindingLabelFor(q),isChecked:this._state.matchCase,hoverDelegate:r,...n})),this._domNode.appendChild(this.caseSensitive.domNode),this._register(this.caseSensitive.onChange((()=>{this._state.change({matchCase:this.caseSensitive.checked},!1)}))),this.wholeWords=this._register(new re.nV({appendTitle:this._keybindingLabelFor($),isChecked:this._state.wholeWord,hoverDelegate:r,...n})),this._domNode.appendChild(this.wholeWords.domNode),this._register(this.wholeWords.onChange((()=>{this._state.change({wholeWord:this.wholeWords.checked},!1)}))),this.regex=this._register(new re.Ix({appendTitle:this._keybindingLabelFor(Q),isChecked:this._state.isRegex,hoverDelegate:r,...n})),this._domNode.appendChild(this.regex.domNode),this._register(this.regex.onChange((()=>{this._state.change({isRegex:this.regex.checked},!1)}))),this._editor.addOverlayWidget(this),this._register(this._state.onFindReplaceStateChange((e=>{let t=!1;e.isRegex&&(this.regex.checked=this._state.isRegex,t=!0),e.wholeWord&&(this.wholeWords.checked=this._state.wholeWord,t=!0),e.matchCase&&(this.caseSensitive.checked=this._state.matchCase,t=!0),!this._state.isRevealed&&t&&this._revealTemporarily()}))),this._register(ne.ko(this._domNode,ne.Bx.MOUSE_LEAVE,(e=>this._onMouseLeave()))),this._register(ne.ko(this._domNode,"mouseover",(e=>this._onMouseOver())))}_keybindingLabelFor(e){const t=this._keybindingService.lookupKeybinding(e);return t?` (${t.getLabel()})`:""}dispose(){this._editor.removeOverlayWidget(this),super.dispose()}getId(){return le.ID}getDomNode(){return this._domNode}getPosition(){return{preference:0}}highlightFindOptions(){this._revealTemporarily()}_revealTemporarily(){this._show(),this._hideSoon.schedule()}_onMouseLeave(){this._hideSoon.schedule()}_onMouseOver(){this._hideSoon.cancel()}_show(){this._isVisible||(this._isVisible=!0,this._domNode.style.display="block")}_hide(){this._isVisible&&(this._isVisible=!1,this._domNode.style.display="none")}}var ce=i(41234);function he(e,t){return 1===e||2!==e&&t}class de extends n.jG{get searchString(){return this._searchString}get replaceString(){return this._replaceString}get isRevealed(){return this._isRevealed}get isReplaceRevealed(){return this._isReplaceRevealed}get isRegex(){return he(this._isRegexOverride,this._isRegex)}get wholeWord(){return he(this._wholeWordOverride,this._wholeWord)}get matchCase(){return he(this._matchCaseOverride,this._matchCase)}get preserveCase(){return he(this._preserveCaseOverride,this._preserveCase)}get actualIsRegex(){return this._isRegex}get actualWholeWord(){return this._wholeWord}get actualMatchCase(){return this._matchCase}get actualPreserveCase(){return this._preserveCase}get searchScope(){return this._searchScope}get matchesPosition(){return this._matchesPosition}get matchesCount(){return this._matchesCount}get currentMatch(){return this._currentMatch}constructor(){super(),this._onFindReplaceStateChange=this._register(new ce.vl),this.onFindReplaceStateChange=this._onFindReplaceStateChange.event,this._searchString="",this._replaceString="",this._isRevealed=!1,this._isReplaceRevealed=!1,this._isRegex=!1,this._isRegexOverride=0,this._wholeWord=!1,this._wholeWordOverride=0,this._matchCase=!1,this._matchCaseOverride=0,this._preserveCase=!1,this._preserveCaseOverride=0,this._searchScope=null,this._matchesPosition=0,this._matchesCount=0,this._currentMatch=null,this._loop=!0,this._isSearching=!1,this._filters=null}changeMatchInfo(e,t,i){const s={moveCursor:!1,updateHistory:!1,searchString:!1,replaceString:!1,isRevealed:!1,isReplaceRevealed:!1,isRegex:!1,wholeWord:!1,matchCase:!1,preserveCase:!1,searchScope:!1,matchesPosition:!1,matchesCount:!1,currentMatch:!1,loop:!1,isSearching:!1,filters:!1};let n=!1;0===t&&(e=0),e>t&&(e=t),this._matchesPosition!==e&&(this._matchesPosition=e,s.matchesPosition=!0,n=!0),this._matchesCount!==t&&(this._matchesCount=t,s.matchesCount=!0,n=!0),"undefined"!==typeof i&&(g.Q.equalsRange(this._currentMatch,i)||(this._currentMatch=i,s.currentMatch=!0,n=!0)),n&&this._onFindReplaceStateChange.fire(s)}change(e,t,i=!0){const s={moveCursor:t,updateHistory:i,searchString:!1,replaceString:!1,isRevealed:!1,isReplaceRevealed:!1,isRegex:!1,wholeWord:!1,matchCase:!1,preserveCase:!1,searchScope:!1,matchesPosition:!1,matchesCount:!1,currentMatch:!1,loop:!1,isSearching:!1,filters:!1};let n=!1;const r=this.isRegex,o=this.wholeWord,a=this.matchCase,l=this.preserveCase;"undefined"!==typeof e.searchString&&this._searchString!==e.searchString&&(this._searchString=e.searchString,s.searchString=!0,n=!0),"undefined"!==typeof e.replaceString&&this._replaceString!==e.replaceString&&(this._replaceString=e.replaceString,s.replaceString=!0,n=!0),"undefined"!==typeof e.isRevealed&&this._isRevealed!==e.isRevealed&&(this._isRevealed=e.isRevealed,s.isRevealed=!0,n=!0),"undefined"!==typeof e.isReplaceRevealed&&this._isReplaceRevealed!==e.isReplaceRevealed&&(this._isReplaceRevealed=e.isReplaceRevealed,s.isReplaceRevealed=!0,n=!0),"undefined"!==typeof e.isRegex&&(this._isRegex=e.isRegex),"undefined"!==typeof e.wholeWord&&(this._wholeWord=e.wholeWord),"undefined"!==typeof e.matchCase&&(this._matchCase=e.matchCase),"undefined"!==typeof e.preserveCase&&(this._preserveCase=e.preserveCase),"undefined"!==typeof e.searchScope&&(e.searchScope?.every((e=>this._searchScope?.some((t=>!g.Q.equalsRange(t,e)))))||(this._searchScope=e.searchScope,s.searchScope=!0,n=!0)),"undefined"!==typeof e.loop&&this._loop!==e.loop&&(this._loop=e.loop,s.loop=!0,n=!0),"undefined"!==typeof e.isSearching&&this._isSearching!==e.isSearching&&(this._isSearching=e.isSearching,s.isSearching=!0,n=!0),"undefined"!==typeof e.filters&&(this._filters?this._filters.update(e.filters):this._filters=e.filters,s.filters=!0,n=!0),this._isRegexOverride="undefined"!==typeof e.isRegexOverride?e.isRegexOverride:0,this._wholeWordOverride="undefined"!==typeof e.wholeWordOverride?e.wholeWordOverride:0,this._matchCaseOverride="undefined"!==typeof e.matchCaseOverride?e.matchCaseOverride:0,this._preserveCaseOverride="undefined"!==typeof e.preserveCaseOverride?e.preserveCaseOverride:0,r!==this.isRegex&&(n=!0,s.isRegex=!0),o!==this.wholeWord&&(n=!0,s.wholeWord=!0),a!==this.matchCase&&(n=!0,s.matchCase=!0),l!==this.preserveCase&&(n=!0,s.preserveCase=!0),n&&this._onFindReplaceStateChange.fire(s)}canNavigateBack(){return this.canNavigateInLoop()||1!==this.matchesPosition}canNavigateForward(){return this.canNavigateInLoop()||this.matchesPosition=ie}}var ue=i(11007),ge=i(35315),pe=i(92403),me=i(10350),fe=i(64383),_e=i(98067),ve=i(78209),Ce=i(89100);function be(e){return"Up"===e.lookupKeybinding("history.showPrevious")?.getElectronAccelerator()&&"Down"===e.lookupKeybinding("history.showNext")?.getElectronAccelerator()}var Ee=i(61394),Se=i(25689),ye=i(86723),we=i(631),Le=i(19070);const Re=(0,Ee.pU)("find-collapsed",me.W.chevronRight,ve.kg("findCollapsedIcon","Icon to indicate that the editor find widget is collapsed.")),Te=(0,Ee.pU)("find-expanded",me.W.chevronDown,ve.kg("findExpandedIcon","Icon to indicate that the editor find widget is expanded.")),xe=(0,Ee.pU)("find-selection",me.W.selection,ve.kg("findSelectionIcon","Icon for 'Find in Selection' in the editor find widget.")),ke=(0,Ee.pU)("find-replace",me.W.replace,ve.kg("findReplaceIcon","Icon for 'Replace' in the editor find widget.")),Ae=(0,Ee.pU)("find-replace-all",me.W.replaceAll,ve.kg("findReplaceAllIcon","Icon for 'Replace All' in the editor find widget.")),Ne=(0,Ee.pU)("find-previous-match",me.W.arrowUp,ve.kg("findPreviousMatchIcon","Icon for 'Find Previous' in the editor find widget.")),Ie=(0,Ee.pU)("find-next-match",me.W.arrowDown,ve.kg("findNextMatchIcon","Icon for 'Find Next' in the editor find widget.")),Oe=ve.kg("label.findDialog","Find / Replace"),De=ve.kg("label.find","Find"),Me=ve.kg("placeholder.find","Find"),Pe=ve.kg("label.previousMatchButton","Previous Match"),Fe=ve.kg("label.nextMatchButton","Next Match"),Ue=ve.kg("label.toggleSelectionFind","Find in Selection"),He=ve.kg("label.closeButton","Close"),Be=ve.kg("label.replace","Replace"),We=ve.kg("placeholder.replace","Replace"),Ve=ve.kg("label.replaceButton","Replace"),ze=ve.kg("label.replaceAllButton","Replace All"),Ge=ve.kg("label.toggleReplaceButton","Toggle Replace"),je=ve.kg("title.matchesCountLimit","Only the first {0} results are highlighted, but all find operations work on the entire text.",ie),Ke=ve.kg("label.matchesLocation","{0} of {1}"),Ye=ve.kg("label.noResults","No results"),qe=419;let $e=69;const Qe="ctrlEnterReplaceAll.windows.donotask",Xe=_e.zx?256:2048;class Ze{constructor(e){this.afterLineNumber=e,this.heightInPx=33,this.suppressMouseDown=!1,this.domNode=document.createElement("div"),this.domNode.className="dock-find-viewzone"}}function Je(e,t,i){const s=!!t.match(/\n/);i&&s&&i.selectionStart>0&&e.stopPropagation()}function et(e,t,i){const s=!!t.match(/\n/);i&&s&&i.selectionEndthis._updateHistoryDelayer.cancel()))),this._register(this._state.onFindReplaceStateChange((e=>this._onStateChanged(e)))),this._buildDomNode(),this._updateButtons(),this._tryUpdateWidgetWidth(),this._findInput.inputBox.layout(),this._register(this._codeEditor.onDidChangeConfiguration((e=>{if(e.hasChanged(92)&&(this._codeEditor.getOption(92)&&this._state.change({isReplaceRevealed:!1},!1),this._updateButtons()),e.hasChanged(146)&&this._tryUpdateWidgetWidth(),e.hasChanged(2)&&this.updateAccessibilitySupport(),e.hasChanged(41)){const e=this._codeEditor.getOption(41).loop;this._state.change({loop:e},!1);const t=this._codeEditor.getOption(41).addExtraSpaceOnTop;t&&!this._viewZone&&(this._viewZone=new Ze(0),this._showViewZone()),!t&&this._viewZone&&this._removeViewZone()}}))),this.updateAccessibilitySupport(),this._register(this._codeEditor.onDidChangeCursorSelection((()=>{this._isVisible&&this._updateToggleSelectionFindButton()}))),this._register(this._codeEditor.onDidFocusEditorWidget((async()=>{if(this._isVisible){const e=await this._controller.getGlobalBufferTerm();e&&e!==this._state.searchString&&(this._state.change({searchString:e},!1),this._findInput.select())}}))),this._findInputFocused=N.bindTo(a),this._findFocusTracker=this._register(ne.w5(this._findInput.inputBox.inputElement)),this._register(this._findFocusTracker.onDidFocus((()=>{this._findInputFocused.set(!0),this._updateSearchScope()}))),this._register(this._findFocusTracker.onDidBlur((()=>{this._findInputFocused.set(!1)}))),this._replaceInputFocused=I.bindTo(a),this._replaceFocusTracker=this._register(ne.w5(this._replaceInput.inputBox.inputElement)),this._register(this._replaceFocusTracker.onDidFocus((()=>{this._replaceInputFocused.set(!0),this._updateSearchScope()}))),this._register(this._replaceFocusTracker.onDidBlur((()=>{this._replaceInputFocused.set(!1)}))),this._codeEditor.addOverlayWidget(this),this._codeEditor.getOption(41).addExtraSpaceOnTop&&(this._viewZone=new Ze(0)),this._register(this._codeEditor.onDidChangeModel((()=>{this._isVisible&&(this._viewZoneId=void 0)}))),this._register(this._codeEditor.onDidScrollChange((e=>{e.scrollTopChanged?this._layoutViewZone():setTimeout((()=>{this._layoutViewZone()}),0)})))}getId(){return tt.ID}getDomNode(){return this._domNode}getPosition(){return this._isVisible?{preference:0}:null}_onStateChanged(e){if(e.searchString){try{this._ignoreChangeEvent=!0,this._findInput.setValue(this._state.searchString)}finally{this._ignoreChangeEvent=!1}this._updateButtons()}if(e.replaceString&&(this._replaceInput.inputBox.value=this._state.replaceString),e.isRevealed&&(this._state.isRevealed?this._reveal():this._hide(!0)),e.isReplaceRevealed&&(this._state.isReplaceRevealed?this._codeEditor.getOption(92)||this._isReplaceVisible||(this._isReplaceVisible=!0,this._replaceInput.width=ne.Tr(this._findInput.domNode),this._updateButtons(),this._replaceInput.inputBox.layout()):this._isReplaceVisible&&(this._isReplaceVisible=!1,this._updateButtons())),(e.isRevealed||e.isReplaceRevealed)&&(this._state.isRevealed||this._state.isReplaceRevealed)&&this._tryUpdateHeight()&&this._showViewZone(),e.isRegex&&this._findInput.setRegex(this._state.isRegex),e.wholeWord&&this._findInput.setWholeWords(this._state.wholeWord),e.matchCase&&this._findInput.setCaseSensitive(this._state.matchCase),e.preserveCase&&this._replaceInput.setPreserveCase(this._state.preserveCase),e.searchScope&&(this._state.searchScope?this._toggleSelectionFind.checked=!0:this._toggleSelectionFind.checked=!1,this._updateToggleSelectionFindButton()),e.searchString||e.matchesCount||e.matchesPosition){const e=this._state.searchString.length>0&&0===this._state.matchesCount;this._domNode.classList.toggle("no-results",e),this._updateMatchesCount(),this._updateButtons()}(e.searchString||e.currentMatch)&&this._layoutViewZone(),e.updateHistory&&this._delayedUpdateHistory(),e.loop&&this._updateButtons()}_delayedUpdateHistory(){this._updateHistoryDelayer.trigger(this._updateHistory.bind(this)).then(void 0,fe.dz)}_updateHistory(){this._state.searchString&&this._findInput.inputBox.addToHistory(),this._state.replaceString&&this._replaceInput.inputBox.addToHistory()}_updateMatchesCount(){let e;if(this._matchesCount.style.minWidth=$e+"px",this._state.matchesCount>=ie?this._matchesCount.title=je:this._matchesCount.title="",this._matchesCount.firstChild?.remove(),this._state.matchesCount>0){let t=String(this._state.matchesCount);this._state.matchesCount>=ie&&(t+="+");let i=String(this._state.matchesPosition);"0"===i&&(i="?"),e=r.GP(Ke,i,t)}else e=Ye;this._matchesCount.appendChild(document.createTextNode(e)),(0,ue.xE)(this._getAriaLabel(e,this._state.currentMatch,this._state.searchString)),$e=Math.max($e,this._matchesCount.clientWidth)}_getAriaLabel(e,t,i){if(e===Ye)return""===i?ve.kg("ariaSearchNoResultEmpty","{0} found",e):ve.kg("ariaSearchNoResult","{0} found for '{1}'",e,i);if(t){const s=ve.kg("ariaSearchNoResultWithLineNum","{0} found for '{1}', at {2}",e,i,t.startLineNumber+":"+t.startColumn),n=this._codeEditor.getModel();if(n&&t.startLineNumber<=n.getLineCount()&&t.startLineNumber>=1){return`${n.getLineContent(t.startLineNumber)}, ${s}`}return s}return ve.kg("ariaSearchNoResultWithLineNumNoCurrentMatch","{0} found for '{1}'",e,i)}_updateToggleSelectionFindButton(){const e=this._codeEditor.getSelection(),t=!!e&&(e.startLineNumber!==e.endLineNumber||e.startColumn!==e.endColumn),i=this._toggleSelectionFind.checked;this._isVisible&&(i||t)?this._toggleSelectionFind.enable():this._toggleSelectionFind.disable()}_updateButtons(){this._findInput.setEnabled(this._isVisible),this._replaceInput.setEnabled(this._isVisible&&this._isReplaceVisible),this._updateToggleSelectionFindButton(),this._closeBtn.setEnabled(this._isVisible);const e=this._state.searchString.length>0,t=!!this._state.matchesCount;this._prevBtn.setEnabled(this._isVisible&&e&&t&&this._state.canNavigateBack()),this._nextBtn.setEnabled(this._isVisible&&e&&t&&this._state.canNavigateForward()),this._replaceBtn.setEnabled(this._isVisible&&this._isReplaceVisible&&e),this._replaceAllBtn.setEnabled(this._isVisible&&this._isReplaceVisible&&e),this._domNode.classList.toggle("replaceToggled",this._isReplaceVisible),this._toggleReplaceBtn.setExpanded(this._isReplaceVisible);const i=!this._codeEditor.getOption(92);this._toggleReplaceBtn.setEnabled(this._isVisible&&i)}_reveal(){if(this._revealTimeouts.forEach((e=>{clearTimeout(e)})),this._revealTimeouts=[],!this._isVisible){this._isVisible=!0;const e=this._codeEditor.getSelection();switch(this._codeEditor.getOption(41).autoFindInSelection){case"always":this._toggleSelectionFind.checked=!0;break;case"never":this._toggleSelectionFind.checked=!1;break;case"multiline":{const t=!!e&&e.startLineNumber!==e.endLineNumber;this._toggleSelectionFind.checked=t;break}}this._tryUpdateWidgetWidth(),this._updateButtons(),this._revealTimeouts.push(setTimeout((()=>{this._domNode.classList.add("visible"),this._domNode.setAttribute("aria-hidden","false")}),0)),this._revealTimeouts.push(setTimeout((()=>{this._findInput.validate()}),200)),this._codeEditor.layoutOverlayWidget(this);let t=!0;if(this._codeEditor.getOption(41).seedSearchStringFromSelection&&e){const i=this._codeEditor.getDomNode();if(i){const s=ne.BK(i),n=this._codeEditor.getScrolledVisiblePosition(e.getStartPosition()),r=s.left+(n?n.left:0),o=n?n.top:0;if(this._viewZone&&oe.startLineNumber&&(t=!1);const i=ne.cL(this._domNode).left;r>i&&(t=!1);const n=this._codeEditor.getScrolledVisiblePosition(e.getEndPosition());s.left+(n?n.left:0)>i&&(t=!1)}}}this._showViewZone(t)}}_hide(e){this._revealTimeouts.forEach((e=>{clearTimeout(e)})),this._revealTimeouts=[],this._isVisible&&(this._isVisible=!1,this._updateButtons(),this._domNode.classList.remove("visible"),this._domNode.setAttribute("aria-hidden","true"),this._findInput.clearMessage(),e&&this._codeEditor.focus(),this._codeEditor.layoutOverlayWidget(this),this._removeViewZone())}_layoutViewZone(e){if(!this._codeEditor.getOption(41).addExtraSpaceOnTop)return void this._removeViewZone();if(!this._isVisible)return;const t=this._viewZone;void 0===this._viewZoneId&&t&&this._codeEditor.changeViewZones((i=>{t.heightInPx=this._getHeight(),this._viewZoneId=i.addZone(t),this._codeEditor.setScrollTop(e||this._codeEditor.getScrollTop()+t.heightInPx)}))}_showViewZone(e=!0){if(!this._isVisible)return;if(!this._codeEditor.getOption(41).addExtraSpaceOnTop)return;void 0===this._viewZone&&(this._viewZone=new Ze(0));const t=this._viewZone;this._codeEditor.changeViewZones((i=>{if(void 0!==this._viewZoneId){const s=this._getHeight();if(s===t.heightInPx)return;const n=s-t.heightInPx;return t.heightInPx=s,i.layoutZone(this._viewZoneId),void(e&&this._codeEditor.setScrollTop(this._codeEditor.getScrollTop()+n))}{let s=this._getHeight();if(s-=this._codeEditor.getOption(84).top,s<=0)return;t.heightInPx=s,this._viewZoneId=i.addZone(t),e&&this._codeEditor.setScrollTop(this._codeEditor.getScrollTop()+s)}}))}_removeViewZone(){this._codeEditor.changeViewZones((e=>{void 0!==this._viewZoneId&&(e.removeZone(this._viewZoneId),this._viewZoneId=void 0,this._viewZone&&(this._codeEditor.setScrollTop(this._codeEditor.getScrollTop()-this._viewZone.heightInPx),this._viewZone=void 0))}))}_tryUpdateWidgetWidth(){if(!this._isVisible)return;if(!this._domNode.isConnected)return;const e=this._codeEditor.getLayoutInfo();if(e.contentWidth<=0)return void this._domNode.classList.add("hiddenEditor");this._domNode.classList.contains("hiddenEditor")&&this._domNode.classList.remove("hiddenEditor");const t=e.width,i=e.minimap.minimapWidth;let s=!1,n=!1,r=!1;if(this._resized){if(ne.Tr(this._domNode)>qe)return this._domNode.style.maxWidth=t-28-i-15+"px",void(this._replaceInput.width=ne.Tr(this._findInput.domNode))}if(447+i>=t&&(n=!0),447+i-$e>=t&&(r=!0),447+i-$e>=t+50&&(s=!0),this._domNode.classList.toggle("collapsed-find-widget",s),this._domNode.classList.toggle("narrow-find-widget",r),this._domNode.classList.toggle("reduced-find-widget",n),r||s||(this._domNode.style.maxWidth=t-28-i-15+"px"),this._findInput.layout({collapsedFindWidget:s,narrowFindWidget:r,reducedFindWidget:n}),this._resized){const e=this._findInput.inputBox.element.clientWidth;e>0&&(this._replaceInput.width=e)}else this._isReplaceVisible&&(this._replaceInput.width=ne.Tr(this._findInput.domNode))}_getHeight(){let e=0;return e+=4,e+=this._findInput.inputBox.height+2,this._isReplaceVisible&&(e+=4,e+=this._replaceInput.inputBox.height+2),e+=4,e}_tryUpdateHeight(){const e=this._getHeight();return(null===this._cachedHeight||this._cachedHeight!==e)&&(this._cachedHeight=e,this._domNode.style.height=`${e}px`,!0)}focusFindInput(){this._findInput.select(),this._findInput.focus()}focusReplaceInput(){this._replaceInput.select(),this._replaceInput.focus()}highlightFindOptions(){this._findInput.highlightFindOptions()}_updateSearchScope(){if(this._codeEditor.hasModel()&&this._toggleSelectionFind.checked){const e=this._codeEditor.getSelections();e.map((e=>{1===e.endColumn&&e.endLineNumber>e.startLineNumber&&(e=e.setEndPosition(e.endLineNumber-1,this._codeEditor.getModel().getLineMaxColumn(e.endLineNumber-1)));const t=this._state.currentMatch;return e.startLineNumber===e.endLineNumber||g.Q.equalsRange(e,t)?null:e})).filter((e=>!!e)),e.length&&this._state.change({searchScope:e},!0)}}_onFindInputMouseDown(e){e.middleButton&&e.stopPropagation()}_onFindInputKeyDown(e){return e.equals(3|Xe)?(this._keybindingService.dispatchEvent(e,e.target)||this._findInput.inputBox.insertAtCursor("\n"),void e.preventDefault()):e.equals(2)?(this._isReplaceVisible?this._replaceInput.focus():this._findInput.focusOnCaseSensitive(),void e.preventDefault()):e.equals(2066)?(this._codeEditor.focus(),void e.preventDefault()):e.equals(16)?Je(e,this._findInput.getValue(),this._findInput.domNode.querySelector("textarea")):e.equals(18)?et(e,this._findInput.getValue(),this._findInput.domNode.querySelector("textarea")):void 0}_onReplaceInputKeyDown(e){return e.equals(3|Xe)?(this._keybindingService.dispatchEvent(e,e.target)||(_e.uF&&_e.ib&&!this._ctrlEnterReplaceAllWarningPrompted&&(this._notificationService.info(ve.kg("ctrlEnter.keybindingChanged","Ctrl+Enter now inserts line break instead of replacing all. You can modify the keybinding for editor.action.replaceAll to override this behavior.")),this._ctrlEnterReplaceAllWarningPrompted=!0,this._storageService.store(Qe,!0,0,0)),this._replaceInput.inputBox.insertAtCursor("\n")),void e.preventDefault()):e.equals(2)?(this._findInput.focusOnCaseSensitive(),void e.preventDefault()):e.equals(1026)?(this._findInput.focus(),void e.preventDefault()):e.equals(2066)?(this._codeEditor.focus(),void e.preventDefault()):e.equals(16)?Je(e,this._replaceInput.inputBox.value,this._replaceInput.inputBox.element.querySelector("textarea")):e.equals(18)?et(e,this._replaceInput.inputBox.value,this._replaceInput.inputBox.element.querySelector("textarea")):void 0}getVerticalSashLeft(e){return 0}_keybindingLabelFor(e){const t=this._keybindingService.lookupKeybinding(e);return t?` (${t.getLabel()})`:""}_buildDomNode(){const e=!0,t=!0;this._findInput=this._register(new Ce.pG(null,this._contextViewProvider,{width:221,label:De,placeholder:Me,appendCaseSensitiveLabel:this._keybindingLabelFor(q),appendWholeWordsLabel:this._keybindingLabelFor($),appendRegexLabel:this._keybindingLabelFor(Q),validation:e=>{if(0===e.length||!this._findInput.getRegex())return null;try{return new RegExp(e,"gu"),null}catch(t){return{content:t.message}}},flexibleHeight:e,flexibleWidth:t,flexibleMaxHeight:118,showCommonFindToggles:!0,showHistoryHint:()=>be(this._keybindingService),inputBoxStyles:Le.ho,toggleStyles:Le.mk},this._contextKeyService)),this._findInput.setRegex(!!this._state.isRegex),this._findInput.setCaseSensitive(!!this._state.matchCase),this._findInput.setWholeWords(!!this._state.wholeWord),this._register(this._findInput.onKeyDown((e=>this._onFindInputKeyDown(e)))),this._register(this._findInput.inputBox.onDidChange((()=>{this._ignoreChangeEvent||this._state.change({searchString:this._findInput.getValue()},!0)}))),this._register(this._findInput.onDidOptionChange((()=>{this._state.change({isRegex:this._findInput.getRegex(),wholeWord:this._findInput.getWholeWords(),matchCase:this._findInput.getCaseSensitive()},!0)}))),this._register(this._findInput.onCaseSensitiveKeyDown((e=>{e.equals(1026)&&this._isReplaceVisible&&(this._replaceInput.focus(),e.preventDefault())}))),this._register(this._findInput.onRegexKeyDown((e=>{e.equals(2)&&this._isReplaceVisible&&(this._replaceInput.focusOnPreserve(),e.preventDefault())}))),this._register(this._findInput.inputBox.onDidHeightChange((e=>{this._tryUpdateHeight()&&this._showViewZone()}))),_e.j9&&this._register(this._findInput.onMouseDown((e=>this._onFindInputMouseDown(e)))),this._matchesCount=document.createElement("div"),this._matchesCount.className="matchesCount",this._updateMatchesCount();const i=this._register((0,ae.bW)());this._prevBtn=this._register(new it({label:Pe+this._keybindingLabelFor(V),icon:Ne,hoverDelegate:i,onTrigger:()=>{(0,we.eU)(this._codeEditor.getAction(V)).run().then(void 0,fe.dz)}},this._hoverService)),this._nextBtn=this._register(new it({label:Fe+this._keybindingLabelFor(W),icon:Ie,hoverDelegate:i,onTrigger:()=>{(0,we.eU)(this._codeEditor.getAction(W)).run().then(void 0,fe.dz)}},this._hoverService));const s=document.createElement("div");s.className="find-part",s.appendChild(this._findInput.domNode);const n=document.createElement("div");n.className="find-actions",s.appendChild(n),n.appendChild(this._matchesCount),n.appendChild(this._prevBtn.domNode),n.appendChild(this._nextBtn.domNode),this._toggleSelectionFind=this._register(new ge.l({icon:xe,title:Ue+this._keybindingLabelFor(X),isChecked:!1,hoverDelegate:i,inputActiveOptionBackground:(0,_.GuP)(_.c1f),inputActiveOptionBorder:(0,_.GuP)(_.uNK),inputActiveOptionForeground:(0,_.GuP)(_.$$0)})),this._register(this._toggleSelectionFind.onChange((()=>{if(this._toggleSelectionFind.checked){if(this._codeEditor.hasModel()){let e=this._codeEditor.getSelections();e=e.map((e=>(1===e.endColumn&&e.endLineNumber>e.startLineNumber&&(e=e.setEndPosition(e.endLineNumber-1,this._codeEditor.getModel().getLineMaxColumn(e.endLineNumber-1))),e.isEmpty()?null:e))).filter((e=>!!e)),e.length&&this._state.change({searchScope:e},!0)}}else this._state.change({searchScope:null},!0)}))),n.appendChild(this._toggleSelectionFind.domNode),this._closeBtn=this._register(new it({label:He+this._keybindingLabelFor(Y),icon:Ee.$_,hoverDelegate:i,onTrigger:()=>{this._state.change({isRevealed:!1,searchScope:null},!1)},onKeyDown:e=>{e.equals(2)&&this._isReplaceVisible&&(this._replaceBtn.isEnabled()?this._replaceBtn.focus():this._codeEditor.focus(),e.preventDefault())}},this._hoverService)),this._replaceInput=this._register(new Ce._Q(null,void 0,{label:Be,placeholder:We,appendPreserveCaseLabel:this._keybindingLabelFor(Z),history:[],flexibleHeight:e,flexibleWidth:t,flexibleMaxHeight:118,showHistoryHint:()=>be(this._keybindingService),inputBoxStyles:Le.ho,toggleStyles:Le.mk},this._contextKeyService,!0)),this._replaceInput.setPreserveCase(!!this._state.preserveCase),this._register(this._replaceInput.onKeyDown((e=>this._onReplaceInputKeyDown(e)))),this._register(this._replaceInput.inputBox.onDidChange((()=>{this._state.change({replaceString:this._replaceInput.inputBox.value},!1)}))),this._register(this._replaceInput.inputBox.onDidHeightChange((e=>{this._isReplaceVisible&&this._tryUpdateHeight()&&this._showViewZone()}))),this._register(this._replaceInput.onDidOptionChange((()=>{this._state.change({preserveCase:this._replaceInput.getPreserveCase()},!0)}))),this._register(this._replaceInput.onPreserveCaseKeyDown((e=>{e.equals(2)&&(this._prevBtn.isEnabled()?this._prevBtn.focus():this._nextBtn.isEnabled()?this._nextBtn.focus():this._toggleSelectionFind.enabled?this._toggleSelectionFind.focus():this._closeBtn.isEnabled()&&this._closeBtn.focus(),e.preventDefault())})));const r=this._register((0,ae.bW)());this._replaceBtn=this._register(new it({label:Ve+this._keybindingLabelFor(J),icon:ke,hoverDelegate:r,onTrigger:()=>{this._controller.replace()},onKeyDown:e=>{e.equals(1026)&&(this._closeBtn.focus(),e.preventDefault())}},this._hoverService)),this._replaceAllBtn=this._register(new it({label:ze+this._keybindingLabelFor(ee),icon:Ae,hoverDelegate:r,onTrigger:()=>{this._controller.replaceAll()}},this._hoverService));const o=document.createElement("div");o.className="replace-part",o.appendChild(this._replaceInput.domNode);const a=document.createElement("div");a.className="replace-actions",o.appendChild(a),a.appendChild(this._replaceBtn.domNode),a.appendChild(this._replaceAllBtn.domNode),this._toggleReplaceBtn=this._register(new it({label:Ge,className:"codicon toggle left",onTrigger:()=>{this._state.change({isReplaceRevealed:!this._isReplaceVisible},!1),this._isReplaceVisible&&(this._replaceInput.width=ne.Tr(this._findInput.domNode),this._replaceInput.inputBox.layout()),this._showViewZone()}},this._hoverService)),this._toggleReplaceBtn.setExpanded(this._isReplaceVisible),this._domNode=document.createElement("div"),this._domNode.className="editor-widget find-widget",this._domNode.setAttribute("aria-hidden","true"),this._domNode.ariaLabel=Oe,this._domNode.role="dialog",this._domNode.style.width="419px",this._domNode.appendChild(this._toggleReplaceBtn.domNode),this._domNode.appendChild(s),this._domNode.appendChild(this._closeBtn.domNode),this._domNode.appendChild(o),this._resizeSash=this._register(new pe.m(this._domNode,this,{orientation:0,size:2})),this._resized=!1;let l=qe;this._register(this._resizeSash.onDidStart((()=>{l=ne.Tr(this._domNode)}))),this._register(this._resizeSash.onDidChange((e=>{this._resized=!0;const t=l+e.startX-e.currentX;if(t(parseFloat(ne.L9(this._domNode).maxWidth)||0)||(this._domNode.style.width=`${t}px`,this._isReplaceVisible&&(this._replaceInput.width=ne.Tr(this._findInput.domNode)),this._findInput.inputBox.layout(),this._tryUpdateHeight())}))),this._register(this._resizeSash.onDidReset((()=>{const e=ne.Tr(this._domNode);if(e{this._opts.onTrigger(),e.preventDefault()})),this.onkeydown(this._domNode,(e=>{if(e.equals(10)||e.equals(3))return this._opts.onTrigger(),void e.preventDefault();this._opts.onKeyDown?.(e)}))}get domNode(){return this._domNode}isEnabled(){return this._domNode.tabIndex>=0}focus(){this._domNode.focus()}setEnabled(e){this._domNode.classList.toggle("disabled",!e),this._domNode.setAttribute("aria-disabled",String(!e)),this._domNode.tabIndex=e?0:-1}setExpanded(e){this._domNode.setAttribute("aria-expanded",String(!!e)),e?(this._domNode.classList.remove(...Se.L.asClassNameArray(Re)),this._domNode.classList.add(...Se.L.asClassNameArray(Te))):(this._domNode.classList.remove(...Se.L.asClassNameArray(Te)),this._domNode.classList.add(...Se.L.asClassNameArray(Re)))}}(0,v.zy)(((e,t)=>{const i=e.getColor(_.ECk);i&&t.addRule(`.monaco-editor .findMatch { border: 1px ${(0,ye.Bb)(e.type)?"dotted":"solid"} ${i}; box-sizing: border-box; }`);const s=e.getColor(_.S5J);s&&t.addRule(`.monaco-editor .findScope { border: 1px ${(0,ye.Bb)(e.type)?"dashed":"solid"} ${s}; }`);const n=e.getColor(_.b1q);n&&t.addRule(`.monaco-editor .find-widget { border: 1px solid ${n}; }`);const r=e.getColor(_.f3U);r&&t.addRule(`.monaco-editor .findMatchInline { color: ${r}; }`);const o=e.getColor(_.p8Y);o&&t.addRule(`.monaco-editor .currentFindMatchInline { color: ${o}; }`)}));var st,nt=i(27195),rt=i(54770),ot=i(47508),at=i(98031),lt=i(58591),ct=i(51467),ht=i(9711),dt=i(67220),ut=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},gt=function(e,t){return function(i,s){t(i,s,e)}};function pt(e,t="single",i=!1){if(!e.hasModel())return null;const s=e.getSelection();if("single"===t&&s.startLineNumber===s.endLineNumber||"multiple"===t)if(s.isEmpty()){const t=e.getConfiguredWordAtPosition(s.getStartPosition());if(t&&!1===i)return t.word}else if(e.getModel().getValueLengthInRange(s)<524288)return e.getModel().getValueInRange(s);return null}let mt=class extends n.jG{static{st=this}static{this.ID="editor.contrib.findController"}get editor(){return this._editor}static get(e){return e.getContribution(st.ID)}constructor(e,t,i,n,r,o){super(),this._editor=e,this._findWidgetVisible=A.bindTo(t),this._contextKeyService=t,this._storageService=i,this._clipboardService=n,this._notificationService=r,this._hoverService=o,this._updateHistoryDelayer=new s.ve(500),this._state=this._register(new de),this.loadQueryState(),this._register(this._state.onFindReplaceStateChange((e=>this._onStateChanged(e)))),this._model=null,this._register(this._editor.onDidChangeModel((()=>{const e=this._editor.getModel()&&this._state.isRevealed;this.disposeModel(),this._state.change({searchScope:null,matchCase:this._storageService.getBoolean("editor.matchCase",1,!1),wholeWord:this._storageService.getBoolean("editor.wholeWord",1,!1),isRegex:this._storageService.getBoolean("editor.isRegex",1,!1),preserveCase:this._storageService.getBoolean("editor.preserveCase",1,!1)},!1),e&&this._start({forceRevealReplace:!1,seedSearchStringFromSelection:"none",seedSearchStringFromNonEmptySelection:!1,seedSearchStringFromGlobalClipboard:!1,shouldFocus:0,shouldAnimate:!1,updateSearchScope:!1,loop:this._editor.getOption(41).loop})})))}dispose(){this.disposeModel(),super.dispose()}disposeModel(){this._model&&(this._model.dispose(),this._model=null)}_onStateChanged(e){this.saveQueryState(e),e.isRevealed&&(this._state.isRevealed?this._findWidgetVisible.set(!0):(this._findWidgetVisible.reset(),this.disposeModel())),e.searchString&&this.setGlobalBufferTerm(this._state.searchString)}saveQueryState(e){e.isRegex&&this._storageService.store("editor.isRegex",this._state.actualIsRegex,1,1),e.wholeWord&&this._storageService.store("editor.wholeWord",this._state.actualWholeWord,1,1),e.matchCase&&this._storageService.store("editor.matchCase",this._state.actualMatchCase,1,1),e.preserveCase&&this._storageService.store("editor.preserveCase",this._state.actualPreserveCase,1,1)}loadQueryState(){this._state.change({matchCase:this._storageService.getBoolean("editor.matchCase",1,this._state.matchCase),wholeWord:this._storageService.getBoolean("editor.wholeWord",1,this._state.wholeWord),isRegex:this._storageService.getBoolean("editor.isRegex",1,this._state.isRegex),preserveCase:this._storageService.getBoolean("editor.preserveCase",1,this._state.preserveCase)},!1)}isFindInputFocused(){return!!N.getValue(this._contextKeyService)}getState(){return this._state}closeFindWidget(){this._state.change({isRevealed:!1,searchScope:null},!1),this._editor.focus()}toggleCaseSensitive(){this._state.change({matchCase:!this._state.matchCase},!1),this._state.isRevealed||this.highlightFindOptions()}toggleWholeWords(){this._state.change({wholeWord:!this._state.wholeWord},!1),this._state.isRevealed||this.highlightFindOptions()}toggleRegex(){this._state.change({isRegex:!this._state.isRegex},!1),this._state.isRevealed||this.highlightFindOptions()}togglePreserveCase(){this._state.change({preserveCase:!this._state.preserveCase},!1),this._state.isRevealed||this.highlightFindOptions()}toggleSearchScope(){if(this._state.searchScope)this._state.change({searchScope:null},!0);else if(this._editor.hasModel()){let e=this._editor.getSelections();e=e.map((e=>(1===e.endColumn&&e.endLineNumber>e.startLineNumber&&(e=e.setEndPosition(e.endLineNumber-1,this._editor.getModel().getLineMaxColumn(e.endLineNumber-1))),e.isEmpty()?null:e))).filter((e=>!!e)),e.length&&this._state.change({searchScope:e},!0)}}setSearchString(e){this._state.isRegex&&(e=r.bm(e)),this._state.change({searchString:e},!1)}highlightFindOptions(e=!1){}async _start(e,t){if(this.disposeModel(),!this._editor.hasModel())return;const i={...t,isRevealed:!0};if("single"===e.seedSearchStringFromSelection){const t=pt(this._editor,e.seedSearchStringFromSelection,e.seedSearchStringFromNonEmptySelection);t&&(this._state.isRegex?i.searchString=r.bm(t):i.searchString=t)}else if("multiple"===e.seedSearchStringFromSelection&&!e.updateSearchScope){const t=pt(this._editor,e.seedSearchStringFromSelection);t&&(i.searchString=t)}if(!i.searchString&&e.seedSearchStringFromGlobalClipboard){const e=await this.getGlobalBufferTerm();if(!this._editor.hasModel())return;e&&(i.searchString=e)}if(e.forceRevealReplace||i.isReplaceRevealed?i.isReplaceRevealed=!0:this._findWidgetVisible.get()||(i.isReplaceRevealed=!1),e.updateSearchScope){const e=this._editor.getSelections();e.some((e=>!e.isEmpty()))&&(i.searchScope=e)}i.loop=e.loop,this._state.change(i,!1),this._model||(this._model=new se(this._editor,this._state))}start(e,t){return this._start(e,t)}moveToNextMatch(){return!!this._model&&(this._model.moveToNextMatch(),!0)}moveToPrevMatch(){return!!this._model&&(this._model.moveToPrevMatch(),!0)}goToMatch(e){return!!this._model&&(this._model.moveToMatch(e),!0)}replace(){return!!this._model&&(this._model.replace(),!0)}replaceAll(){return!!this._model&&(this._editor.getModel()?.isTooLargeForHeapOperation()?(this._notificationService.warn(ve.kg("too.large.for.replaceall","The file is too large to perform a replace all operation.")),!1):(this._model.replaceAll(),!0))}selectAllMatches(){return!!this._model&&(this._model.selectAllMatches(),this._editor.focus(),!0)}async getGlobalBufferTerm(){return this._editor.getOption(41).globalFindClipboard&&this._editor.hasModel()&&!this._editor.getModel().isTooLargeForSyncing()?this._clipboardService.readFindText():""}setGlobalBufferTerm(e){this._editor.getOption(41).globalFindClipboard&&this._editor.hasModel()&&!this._editor.getModel().isTooLargeForSyncing()&&this._clipboardService.writeFindText(e)}};mt=st=ut([gt(1,k.fN),gt(2,ht.CS),gt(3,rt.h),gt(4,lt.Ot),gt(5,dt.TN)],mt);let ft=class extends mt{constructor(e,t,i,s,n,r,o,a,l){super(e,i,o,a,r,l),this._contextViewService=t,this._keybindingService=s,this._themeService=n,this._widget=null,this._findOptionsWidget=null}async _start(e,t){this._widget||this._createFindWidget();const i=this._editor.getSelection();let s=!1;switch(this._editor.getOption(41).autoFindInSelection){case"always":s=!0;break;case"never":s=!1;break;case"multiline":s=!!i&&i.startLineNumber!==i.endLineNumber;break}e.updateSearchScope=e.updateSearchScope||s,await super._start(e,t),this._widget&&(2===e.shouldFocus?this._widget.focusReplaceInput():1===e.shouldFocus&&this._widget.focusFindInput())}highlightFindOptions(e=!1){this._widget||this._createFindWidget(),this._state.isRevealed&&!e?this._widget.highlightFindOptions():this._findOptionsWidget.highlightFindOptions()}_createFindWidget(){this._widget=this._register(new tt(this._editor,this,this._state,this._contextViewService,this._keybindingService,this._contextKeyService,this._themeService,this._storageService,this._notificationService,this._hoverService)),this._findOptionsWidget=this._register(new le(this._editor,this._state,this._keybindingService))}};ft=ut([gt(1,ot.l),gt(2,k.fN),gt(3,at.b),gt(4,v.Gy),gt(5,lt.Ot),gt(6,ht.CS),gt(7,rt.h),gt(8,dt.TN)],ft);(0,o.gW)(new o.PF({id:U,label:ve.kg("startFindAction","Find"),alias:"Find",precondition:k.M$.or(l.R.focus,k.M$.has("editorIsOpen")),kbOpts:{kbExpr:null,primary:2084,weight:100},menuOpts:{menuId:nt.D8.MenubarEditMenu,group:"3_find",title:ve.kg({key:"miFind",comment:["&& denotes a mnemonic"]},"&&Find"),order:1}})).addImplementation(0,((e,t,i)=>{const s=mt.get(t);return!!s&&s.start({forceRevealReplace:!1,seedSearchStringFromSelection:"never"!==t.getOption(41).seedSearchStringFromSelection?"single":"none",seedSearchStringFromNonEmptySelection:"selection"===t.getOption(41).seedSearchStringFromSelection,seedSearchStringFromGlobalClipboard:t.getOption(41).globalFindClipboard,shouldFocus:1,shouldAnimate:!0,updateSearchScope:!1,loop:t.getOption(41).loop})}));const _t={description:"Open a new In-Editor Find Widget.",args:[{name:"Open a new In-Editor Find Widget args",schema:{properties:{searchString:{type:"string"},replaceString:{type:"string"},isRegex:{type:"boolean"},matchWholeWord:{type:"boolean"},isCaseSensitive:{type:"boolean"},preserveCase:{type:"boolean"},findInSelection:{type:"boolean"}}}}]};class vt extends o.ks{constructor(){super({id:B,label:ve.kg("startFindWithArgsAction","Find With Arguments"),alias:"Find With Arguments",precondition:void 0,kbOpts:{kbExpr:null,primary:0,weight:100},metadata:_t})}async run(e,t,i){const s=mt.get(t);if(s){const e=i?{searchString:i.searchString,replaceString:i.replaceString,isReplaceRevealed:void 0!==i.replaceString,isRegex:i.isRegex,wholeWord:i.matchWholeWord,matchCase:i.isCaseSensitive,preserveCase:i.preserveCase}:{};await s.start({forceRevealReplace:!1,seedSearchStringFromSelection:0===s.getState().searchString.length&&"never"!==t.getOption(41).seedSearchStringFromSelection?"single":"none",seedSearchStringFromNonEmptySelection:"selection"===t.getOption(41).seedSearchStringFromSelection,seedSearchStringFromGlobalClipboard:!0,shouldFocus:1,shouldAnimate:!0,updateSearchScope:i?.findInSelection||!1,loop:t.getOption(41).loop},e),s.setGlobalBufferTerm(s.getState().searchString)}}}class Ct extends o.ks{constructor(){super({id:H,label:ve.kg("startFindWithSelectionAction","Find With Selection"),alias:"Find With Selection",precondition:void 0,kbOpts:{kbExpr:null,primary:0,mac:{primary:2083},weight:100}})}async run(e,t){const i=mt.get(t);i&&(await i.start({forceRevealReplace:!1,seedSearchStringFromSelection:"multiple",seedSearchStringFromNonEmptySelection:!1,seedSearchStringFromGlobalClipboard:!1,shouldFocus:0,shouldAnimate:!0,updateSearchScope:!1,loop:t.getOption(41).loop}),i.setGlobalBufferTerm(i.getState().searchString))}}class bt extends o.ks{async run(e,t){const i=mt.get(t);i&&!this._run(i)&&(await i.start({forceRevealReplace:!1,seedSearchStringFromSelection:0===i.getState().searchString.length&&"never"!==t.getOption(41).seedSearchStringFromSelection?"single":"none",seedSearchStringFromNonEmptySelection:"selection"===t.getOption(41).seedSearchStringFromSelection,seedSearchStringFromGlobalClipboard:!0,shouldFocus:0,shouldAnimate:!0,updateSearchScope:!1,loop:t.getOption(41).loop}),this._run(i))}}class Et extends o.ks{constructor(){super({id:z,label:ve.kg("findMatchAction.goToMatch","Go to Match..."),alias:"Go to Match...",precondition:A}),this._highlightDecorations=[]}run(e,t,i){const s=mt.get(t);if(!s)return;const r=s.getState().matchesCount;if(r<1){return void e.get(lt.Ot).notify({severity:lt.AI.Warning,message:ve.kg("findMatchAction.noResults","No matches. Try searching for something else.")})}const o=e.get(ct.GK),a=new n.Cm,l=a.add(o.createInputBox());l.placeholder=ve.kg("findMatchAction.inputPlaceHolder","Type a number to go to a specific match (between 1 and {0})",r);const c=e=>{const t=parseInt(e);if(isNaN(t))return;const i=s.getState().matchesCount;return t>0&&t<=i?t-1:t<0&&t>=-i?i+t:void 0},h=e=>{const i=c(e);if("number"===typeof i){l.validationMessage=void 0,s.goToMatch(i);const e=s.getState().currentMatch;e&&this.addDecorations(t,e)}else l.validationMessage=ve.kg("findMatchAction.inputValidationMessage","Please type a number between 1 and {0}",s.getState().matchesCount),this.clearDecorations(t)};a.add(l.onDidChangeValue((e=>{h(e)}))),a.add(l.onDidAccept((()=>{const e=c(l.value);"number"===typeof e?(s.goToMatch(e),l.hide()):l.validationMessage=ve.kg("findMatchAction.inputValidationMessage","Please type a number between 1 and {0}",s.getState().matchesCount)}))),a.add(l.onDidHide((()=>{this.clearDecorations(t),a.dispose()}))),l.show()}clearDecorations(e){e.changeDecorations((e=>{this._highlightDecorations=e.deltaDecorations(this._highlightDecorations,[])}))}addDecorations(e,t){e.changeDecorations((e=>{this._highlightDecorations=e.deltaDecorations(this._highlightDecorations,[{range:t,options:{description:"find-match-quick-access-range-highlight",className:"rangeHighlight",isWholeLine:!0}},{range:t,options:{description:"find-match-quick-access-range-highlight-overview",overviewRuler:{color:(0,v.Yf)(a.vp),position:c.A5.Full}}}])}))}}class St extends o.ks{async run(e,t){const i=mt.get(t);if(!i)return;const s=pt(t,"single",!1);s&&i.setSearchString(s),this._run(i)||(await i.start({forceRevealReplace:!1,seedSearchStringFromSelection:"none",seedSearchStringFromNonEmptySelection:!1,seedSearchStringFromGlobalClipboard:!1,shouldFocus:0,shouldAnimate:!0,updateSearchScope:!1,loop:t.getOption(41).loop}),this._run(i))}}(0,o.gW)(new o.PF({id:K,label:ve.kg("startReplace","Replace"),alias:"Replace",precondition:k.M$.or(l.R.focus,k.M$.has("editorIsOpen")),kbOpts:{kbExpr:null,primary:2086,mac:{primary:2596},weight:100},menuOpts:{menuId:nt.D8.MenubarEditMenu,group:"3_find",title:ve.kg({key:"miReplace",comment:["&& denotes a mnemonic"]},"&&Replace"),order:2}})).addImplementation(0,((e,t,i)=>{if(!t.hasModel()||t.getOption(92))return!1;const s=mt.get(t);if(!s)return!1;const n=t.getSelection(),r=s.isFindInputFocused(),o=!n.isEmpty()&&n.startLineNumber===n.endLineNumber&&"never"!==t.getOption(41).seedSearchStringFromSelection&&!r,a=r||o?2:1;return s.start({forceRevealReplace:!0,seedSearchStringFromSelection:o?"single":"none",seedSearchStringFromNonEmptySelection:"selection"===t.getOption(41).seedSearchStringFromSelection,seedSearchStringFromGlobalClipboard:"never"!==t.getOption(41).seedSearchStringFromSelection,shouldFocus:a,shouldAnimate:!0,updateSearchScope:!1,loop:t.getOption(41).loop})})),(0,o.HW)(mt.ID,ft,0),(0,o.Fl)(vt),(0,o.Fl)(Ct),(0,o.Fl)(class extends bt{constructor(){super({id:W,label:ve.kg("findNextMatchAction","Find Next"),alias:"Find Next",precondition:void 0,kbOpts:[{kbExpr:l.R.focus,primary:61,mac:{primary:2085,secondary:[61]},weight:100},{kbExpr:k.M$.and(l.R.focus,N),primary:3,weight:100}]})}_run(e){return!!e.moveToNextMatch()&&(e.editor.pushUndoStop(),!0)}}),(0,o.Fl)(class extends bt{constructor(){super({id:V,label:ve.kg("findPreviousMatchAction","Find Previous"),alias:"Find Previous",precondition:void 0,kbOpts:[{kbExpr:l.R.focus,primary:1085,mac:{primary:3109,secondary:[1085]},weight:100},{kbExpr:k.M$.and(l.R.focus,N),primary:1027,weight:100}]})}_run(e){return e.moveToPrevMatch()}}),(0,o.Fl)(Et),(0,o.Fl)(class extends St{constructor(){super({id:G,label:ve.kg("nextSelectionMatchFindAction","Find Next Selection"),alias:"Find Next Selection",precondition:void 0,kbOpts:{kbExpr:l.R.focus,primary:2109,weight:100}})}_run(e){return e.moveToNextMatch()}}),(0,o.Fl)(class extends St{constructor(){super({id:j,label:ve.kg("previousSelectionMatchFindAction","Find Previous Selection"),alias:"Find Previous Selection",precondition:void 0,kbOpts:{kbExpr:l.R.focus,primary:3133,weight:100}})}_run(e){return e.moveToPrevMatch()}});const yt=o.DX.bindToContribution(mt.get);(0,o.E_)(new yt({id:Y,precondition:A,handler:e=>e.closeFindWidget(),kbOpts:{weight:105,kbExpr:k.M$.and(l.R.focus,k.M$.not("isComposing")),primary:9,secondary:[1033]}})),(0,o.E_)(new yt({id:q,precondition:void 0,handler:e=>e.toggleCaseSensitive(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:O.primary,mac:O.mac,win:O.win,linux:O.linux}})),(0,o.E_)(new yt({id:$,precondition:void 0,handler:e=>e.toggleWholeWords(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:D.primary,mac:D.mac,win:D.win,linux:D.linux}})),(0,o.E_)(new yt({id:Q,precondition:void 0,handler:e=>e.toggleRegex(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:M.primary,mac:M.mac,win:M.win,linux:M.linux}})),(0,o.E_)(new yt({id:X,precondition:void 0,handler:e=>e.toggleSearchScope(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:P.primary,mac:P.mac,win:P.win,linux:P.linux}})),(0,o.E_)(new yt({id:Z,precondition:void 0,handler:e=>e.togglePreserveCase(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:F.primary,mac:F.mac,win:F.win,linux:F.linux}})),(0,o.E_)(new yt({id:J,precondition:A,handler:e=>e.replace(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:3094}})),(0,o.E_)(new yt({id:J,precondition:A,handler:e=>e.replace(),kbOpts:{weight:105,kbExpr:k.M$.and(l.R.focus,I),primary:3}})),(0,o.E_)(new yt({id:ee,precondition:A,handler:e=>e.replaceAll(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:2563}})),(0,o.E_)(new yt({id:ee,precondition:A,handler:e=>e.replaceAll(),kbOpts:{weight:105,kbExpr:k.M$.and(l.R.focus,I),primary:void 0,mac:{primary:2051}}})),(0,o.E_)(new yt({id:te,precondition:A,handler:e=>e.selectAllMatches(),kbOpts:{weight:105,kbExpr:l.R.focus,primary:515}}))},44588:(e,t,i)=>{"use strict";i.d(t,{WR:()=>B,BP:()=>W});var s=i(90766),n=i(18447),r=i(64383),o=i(24939),a=i(5662),l=i(91508),c=i(631),h=i(55190),d=i(31450),u=i(60002),g=i(62083),p=i(17469),m=i(52903),f=i(46041),_=i(41234),v=i(36677),C=i(64454);class b{get onDidChange(){return this._updateEventEmitter.event}get hiddenRanges(){return this._hiddenRanges}constructor(e){this._updateEventEmitter=new _.vl,this._hasLineChanges=!1,this._foldingModel=e,this._foldingModelListener=e.onDidChange((e=>this.updateHiddenRanges())),this._hiddenRanges=[],e.regions.length&&this.updateHiddenRanges()}notifyChangeModelContent(e){this._hiddenRanges.length&&!this._hasLineChanges&&(this._hasLineChanges=e.changes.some((e=>e.range.endLineNumber!==e.range.startLineNumber||0!==(0,C.W)(e.text)[0])))}updateHiddenRanges(){let e=!1;const t=[];let i=0,s=0,n=Number.MAX_VALUE,r=-1;const o=this._foldingModel.regions;for(;i0}isHidden(e){return null!==E(this._hiddenRanges,e)}adjustSelections(e){let t=!1;const i=this._foldingModel.textModel;let s=null;const n=e=>(s&&function(e,t){return e>=t.startLineNumber&&e<=t.endLineNumber}(e,s)||(s=E(this._hiddenRanges,e)),s?s.startLineNumber-1:null);for(let r=0,o=e.length;r0&&(this._hiddenRanges=[],this._updateEventEmitter.fire(this._hiddenRanges)),this._foldingModelListener&&(this._foldingModelListener.dispose(),this._foldingModelListener=null)}}function E(e,t){const i=(0,f.hw)(e,(e=>t=0&&e[i].endLineNumber>=t?e[i]:null}var S,y=i(76495),w=i(78209),L=i(32848),R=i(46109),T=i(44026),x=i(87784),k=i(58591),A=i(32500),N=i(78381),I=i(56942),O=i(50091),D=i(79400),M=i(23750),P=i(84001),F=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},U=function(e,t){return function(i,s){t(i,s,e)}};const H=new L.N1("foldingEnabled",!1);let B=class extends a.jG{static{S=this}static{this.ID="editor.contrib.folding"}static get(e){return e.getContribution(S.ID)}static getFoldingRangeProviders(e,t){const i=e.foldingRangeProvider.ordered(t);return S._foldingRangeSelector?.(i,t)??i}constructor(e,t,i,s,n,r){super(),this.contextKeyService=t,this.languageConfigurationService=i,this.languageFeaturesService=r,this.localToDispose=this._register(new a.Cm),this.editor=e,this._foldingLimitReporter=new W(e);const o=this.editor.getOptions();this._isEnabled=o.get(43),this._useFoldingProviders="indentation"!==o.get(44),this._unfoldOnClickAfterEndOfLine=o.get(48),this._restoringViewState=!1,this._currentModelHasFoldedImports=!1,this._foldingImportsByDefault=o.get(46),this.updateDebounceInfo=n.for(r.foldingRangeProvider,"Folding",{min:200}),this.foldingModel=null,this.hiddenRangeModel=null,this.rangeProvider=null,this.foldingRegionPromise=null,this.foldingModelPromise=null,this.updateScheduler=null,this.cursorChangedScheduler=null,this.mouseDownInfo=null,this.foldingDecorationProvider=new R.rv(e),this.foldingDecorationProvider.showFoldingControls=o.get(111),this.foldingDecorationProvider.showFoldingHighlights=o.get(45),this.foldingEnabled=H.bindTo(this.contextKeyService),this.foldingEnabled.set(this._isEnabled),this._register(this.editor.onDidChangeModel((()=>this.onModelChanged()))),this._register(this.editor.onDidChangeConfiguration((e=>{if(e.hasChanged(43)&&(this._isEnabled=this.editor.getOptions().get(43),this.foldingEnabled.set(this._isEnabled),this.onModelChanged()),e.hasChanged(47)&&this.onModelChanged(),e.hasChanged(111)||e.hasChanged(45)){const e=this.editor.getOptions();this.foldingDecorationProvider.showFoldingControls=e.get(111),this.foldingDecorationProvider.showFoldingHighlights=e.get(45),this.triggerFoldingModelChanged()}e.hasChanged(44)&&(this._useFoldingProviders="indentation"!==this.editor.getOptions().get(44),this.onFoldingStrategyChanged()),e.hasChanged(48)&&(this._unfoldOnClickAfterEndOfLine=this.editor.getOptions().get(48)),e.hasChanged(46)&&(this._foldingImportsByDefault=this.editor.getOptions().get(46))}))),this.onModelChanged()}saveViewState(){const e=this.editor.getModel();if(!e||!this._isEnabled||e.isTooLargeForTokenization())return{};if(this.foldingModel){const t=this.foldingModel.getMemento(),i=this.rangeProvider?this.rangeProvider.id:void 0;return{collapsedRegions:t,lineCount:e.getLineCount(),provider:i,foldedImports:this._currentModelHasFoldedImports}}}restoreViewState(e){const t=this.editor.getModel();if(t&&this._isEnabled&&!t.isTooLargeForTokenization()&&this.hiddenRangeModel&&e&&(this._currentModelHasFoldedImports=!!e.foldedImports,e.collapsedRegions&&e.collapsedRegions.length>0&&this.foldingModel)){this._restoringViewState=!0;try{this.foldingModel.applyMemento(e.collapsedRegions)}finally{this._restoringViewState=!1}}}onModelChanged(){this.localToDispose.clear();const e=this.editor.getModel();this._isEnabled&&e&&!e.isTooLargeForTokenization()&&(this._currentModelHasFoldedImports=!1,this.foldingModel=new m.pN(e,this.foldingDecorationProvider),this.localToDispose.add(this.foldingModel),this.hiddenRangeModel=new b(this.foldingModel),this.localToDispose.add(this.hiddenRangeModel),this.localToDispose.add(this.hiddenRangeModel.onDidChange((e=>this.onHiddenRangesChanges(e)))),this.updateScheduler=new s.ve(this.updateDebounceInfo.get(e)),this.cursorChangedScheduler=new s.uC((()=>this.revealCursor()),200),this.localToDispose.add(this.cursorChangedScheduler),this.localToDispose.add(this.languageFeaturesService.foldingRangeProvider.onDidChange((()=>this.onFoldingStrategyChanged()))),this.localToDispose.add(this.editor.onDidChangeModelLanguageConfiguration((()=>this.onFoldingStrategyChanged()))),this.localToDispose.add(this.editor.onDidChangeModelContent((e=>this.onDidChangeModelContent(e)))),this.localToDispose.add(this.editor.onDidChangeCursorPosition((()=>this.onCursorPositionChanged()))),this.localToDispose.add(this.editor.onMouseDown((e=>this.onEditorMouseDown(e)))),this.localToDispose.add(this.editor.onMouseUp((e=>this.onEditorMouseUp(e)))),this.localToDispose.add({dispose:()=>{this.foldingRegionPromise&&(this.foldingRegionPromise.cancel(),this.foldingRegionPromise=null),this.updateScheduler?.cancel(),this.updateScheduler=null,this.foldingModel=null,this.foldingModelPromise=null,this.hiddenRangeModel=null,this.cursorChangedScheduler=null,this.rangeProvider?.dispose(),this.rangeProvider=null}}),this.triggerFoldingModelChanged())}onFoldingStrategyChanged(){this.rangeProvider?.dispose(),this.rangeProvider=null,this.triggerFoldingModelChanged()}getRangeProvider(e){if(this.rangeProvider)return this.rangeProvider;const t=new y.hW(e,this.languageConfigurationService,this._foldingLimitReporter);if(this.rangeProvider=t,this._useFoldingProviders&&this.foldingModel){const i=S.getFoldingRangeProviders(this.languageFeaturesService,e);i.length>0&&(this.rangeProvider=new x.M(e,i,(()=>this.triggerFoldingModelChanged()),this._foldingLimitReporter,t))}return this.rangeProvider}getFoldingModel(){return this.foldingModelPromise}onDidChangeModelContent(e){this.hiddenRangeModel?.notifyChangeModelContent(e),this.triggerFoldingModelChanged()}triggerFoldingModelChanged(){this.updateScheduler&&(this.foldingRegionPromise&&(this.foldingRegionPromise.cancel(),this.foldingRegionPromise=null),this.foldingModelPromise=this.updateScheduler.trigger((()=>{const e=this.foldingModel;if(!e)return null;const t=new N.W,i=this.getRangeProvider(e.textModel),n=this.foldingRegionPromise=(0,s.SS)((e=>i.compute(e)));return n.then((i=>{if(i&&n===this.foldingRegionPromise){let s;if(this._foldingImportsByDefault&&!this._currentModelHasFoldedImports){const e=i.setCollapsedAllOfType(g.lO.Imports.value,!0);e&&(s=h.D.capture(this.editor),this._currentModelHasFoldedImports=e)}const n=this.editor.getSelections();e.update(i,function(e){if(!e||0===e.length)return{startsInside:()=>!1};return{startsInside(t,i){for(const s of e){const e=s.startLineNumber;if(e>=t&&e<=i)return!0}return!1}}}(n)),s?.restore(this.editor);const r=this.updateDebounceInfo.update(e.textModel,t.elapsed());this.updateScheduler&&(this.updateScheduler.defaultDelay=r)}return e}))})).then(void 0,(e=>((0,r.dz)(e),null))))}onHiddenRangesChanges(e){if(this.hiddenRangeModel&&e.length&&!this._restoringViewState){const e=this.editor.getSelections();e&&this.hiddenRangeModel.adjustSelections(e)&&this.editor.setSelections(e)}this.editor.setHiddenAreas(e,this)}onCursorPositionChanged(){this.hiddenRangeModel&&this.hiddenRangeModel.hasRanges()&&this.cursorChangedScheduler.schedule()}revealCursor(){const e=this.getFoldingModel();e&&e.then((e=>{if(e){const t=this.editor.getSelections();if(t&&t.length>0){const i=[];for(const s of t){const t=s.selectionStartLineNumber;this.hiddenRangeModel&&this.hiddenRangeModel.isHidden(t)&&i.push(...e.getAllRegionsAtLine(t,(e=>e.isCollapsed&&t>e.startLineNumber)))}i.length&&(e.toggleCollapseState(i),this.reveal(t[0].getPosition()))}}})).then(void 0,r.dz)}onEditorMouseDown(e){if(this.mouseDownInfo=null,!this.hiddenRangeModel||!e.target||!e.target.range)return;if(!e.event.leftButton&&!e.event.middleButton)return;const t=e.target.range;let i=!1;switch(e.target.type){case 4:{const t=e.target.detail,s=e.target.element.offsetLeft;if(t.offsetX-s<4)return;i=!0;break}case 7:if(this._unfoldOnClickAfterEndOfLine&&this.hiddenRangeModel.hasRanges()){if(!e.target.detail.isAfterLines)break}return;case 6:if(this.hiddenRangeModel.hasRanges()){const e=this.editor.getModel();if(e&&t.startColumn===e.getLineMaxColumn(t.startLineNumber))break}return;default:return}this.mouseDownInfo={lineNumber:t.startLineNumber,iconClicked:i}}onEditorMouseUp(e){const t=this.foldingModel;if(!t||!this.mouseDownInfo||!e.target)return;const i=this.mouseDownInfo.lineNumber,s=this.mouseDownInfo.iconClicked,n=e.target.range;if(!n||n.startLineNumber!==i)return;if(s){if(4!==e.target.type)return}else{const e=this.editor.getModel();if(!e||n.startColumn!==e.getLineMaxColumn(i))return}const r=t.getRegionAtLine(i);if(r&&r.startLineNumber===i){const n=r.isCollapsed;if(s||n){let s=[];if(e.event.altKey){const e=e=>!e.containedBy(r)&&!r.containedBy(e),i=t.getRegionsInside(null,e);for(const t of i)t.isCollapsed&&s.push(t);0===s.length&&(s=i)}else{const i=e.event.middleButton||e.event.shiftKey;if(i)for(const e of t.getRegionsInside(r))e.isCollapsed===n&&s.push(e);!n&&i&&0!==s.length||s.push(r)}t.toggleCollapseState(s),this.reveal({lineNumber:i,column:1})}}}reveal(e){this.editor.revealPositionInCenterIfOutsideViewport(e,0)}};B=S=F([U(1,L.fN),U(2,p.JZ),U(3,k.Ot),U(4,A.ILanguageFeatureDebounceService),U(5,I.ILanguageFeaturesService)],B);class W{constructor(e){this.editor=e,this._onDidChange=new _.vl,this._computed=0,this._limited=!1}get limit(){return this.editor.getOptions().get(47)}update(e,t){e===this._computed&&t===this._limited||(this._computed=e,this._limited=t,this._onDidChange.fire())}}class V extends d.ks{runEditorCommand(e,t,i){const s=e.get(p.JZ),n=B.get(t);if(!n)return;const r=n.getFoldingModel();return r?(this.reportTelemetry(e,t),r.then((e=>{if(e){this.invoke(n,e,t,i,s);const r=t.getSelection();r&&n.reveal(r.getStartPosition())}}))):void 0}getSelectedLines(e){const t=e.getSelections();return t?t.map((e=>e.startLineNumber)):[]}getLineNumbers(e,t){return e&&e.selectionLines?e.selectionLines.map((e=>e+1)):this.getSelectedLines(t)}run(e,t){}}function z(e){if(!c.b0(e)){if(!c.Gv(e))return!1;const t=e;if(!c.b0(t.levels)&&!c.Et(t.levels))return!1;if(!c.b0(t.direction)&&!c.Kg(t.direction))return!1;if(!c.b0(t.selectionLines)&&(!Array.isArray(t.selectionLines)||!t.selectionLines.every(c.Et)))return!1}return!0}class G extends V{static{this.ID_PREFIX="editor.foldLevel"}static{this.ID=e=>G.ID_PREFIX+e}getFoldingLevel(){return parseInt(this.id.substr(G.ID_PREFIX.length))}invoke(e,t,i){(0,m.sO)(t,this.getFoldingLevel(),!0,this.getSelectedLines(i))}}(0,d.HW)(B.ID,B,0),(0,d.Fl)(class extends V{constructor(){super({id:"editor.unfold",label:w.kg("unfoldAction.label","Unfold"),alias:"Unfold",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:3166,mac:{primary:2654},weight:100},metadata:{description:"Unfold the content in the editor",args:[{name:"Unfold editor argument",description:"Property-value pairs that can be passed through this argument:\n\t\t\t\t\t\t* 'levels': Number of levels to unfold. If not set, defaults to 1.\n\t\t\t\t\t\t* 'direction': If 'up', unfold given number of levels up otherwise unfolds down.\n\t\t\t\t\t\t* 'selectionLines': Array of the start lines (0-based) of the editor selections to apply the unfold action to. If not set, the active selection(s) will be used.\n\t\t\t\t\t\t",constraint:z,schema:{type:"object",properties:{levels:{type:"number",default:1},direction:{type:"string",enum:["up","down"],default:"down"},selectionLines:{type:"array",items:{type:"number"}}}}}]}})}invoke(e,t,i,s){const n=s&&s.levels||1,r=this.getLineNumbers(s,i);s&&"up"===s.direction?(0,m.dN)(t,!1,n,r):(0,m.uV)(t,!1,n,r)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.unfoldRecursively",label:w.kg("unFoldRecursivelyAction.label","Unfold Recursively"),alias:"Unfold Recursively",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2142),weight:100}})}invoke(e,t,i,s){(0,m.uV)(t,!1,Number.MAX_VALUE,this.getSelectedLines(i))}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.fold",label:w.kg("foldAction.label","Fold"),alias:"Fold",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:3164,mac:{primary:2652},weight:100},metadata:{description:"Fold the content in the editor",args:[{name:"Fold editor argument",description:"Property-value pairs that can be passed through this argument:\n\t\t\t\t\t\t\t* 'levels': Number of levels to fold.\n\t\t\t\t\t\t\t* 'direction': If 'up', folds given number of levels up otherwise folds down.\n\t\t\t\t\t\t\t* 'selectionLines': Array of the start lines (0-based) of the editor selections to apply the fold action to. If not set, the active selection(s) will be used.\n\t\t\t\t\t\t\tIf no levels or direction is set, folds the region at the locations or if already collapsed, the first uncollapsed parent instead.\n\t\t\t\t\t\t",constraint:z,schema:{type:"object",properties:{levels:{type:"number"},direction:{type:"string",enum:["up","down"]},selectionLines:{type:"array",items:{type:"number"}}}}}]}})}invoke(e,t,i,s){const n=this.getLineNumbers(s,i),r=s&&s.levels,o=s&&s.direction;"number"!==typeof r&&"string"!==typeof o?(0,m.W8)(t,!0,n):"up"===o?(0,m.dN)(t,!0,r||1,n):(0,m.uV)(t,!0,r||1,n)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.foldRecursively",label:w.kg("foldRecursivelyAction.label","Fold Recursively"),alias:"Fold Recursively",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2140),weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);(0,m.uV)(t,!0,Number.MAX_VALUE,s)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.toggleFoldRecursively",label:w.kg("toggleFoldRecursivelyAction.label","Toggle Fold Recursively"),alias:"Toggle Fold Recursively",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,3114),weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);(0,m.bC)(t,Number.MAX_VALUE,s)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.foldAll",label:w.kg("foldAllAction.label","Fold All"),alias:"Fold All",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2069),weight:100}})}invoke(e,t,i){(0,m.uV)(t,!0)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.unfoldAll",label:w.kg("unfoldAllAction.label","Unfold All"),alias:"Unfold All",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2088),weight:100}})}invoke(e,t,i){(0,m.uV)(t,!1)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.foldAllBlockComments",label:w.kg("foldAllBlockComments.label","Fold All Block Comments"),alias:"Fold All Block Comments",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2138),weight:100}})}invoke(e,t,i,s,n){if(t.regions.hasTypes())(0,m.cL)(t,g.lO.Comment.value,!0);else{const e=i.getModel();if(!e)return;const s=n.getLanguageConfiguration(e.getLanguageId()).comments;if(s&&s.blockCommentStartToken){const e=new RegExp("^\\s*"+(0,l.bm)(s.blockCommentStartToken));(0,m.AI)(t,e,!0)}}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.foldAllMarkerRegions",label:w.kg("foldAllMarkerRegions.label","Fold All Regions"),alias:"Fold All Regions",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2077),weight:100}})}invoke(e,t,i,s,n){if(t.regions.hasTypes())(0,m.cL)(t,g.lO.Region.value,!0);else{const e=i.getModel();if(!e)return;const s=n.getLanguageConfiguration(e.getLanguageId()).foldingRules;if(s&&s.markers&&s.markers.start){const e=new RegExp(s.markers.start);(0,m.AI)(t,e,!0)}}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.unfoldAllMarkerRegions",label:w.kg("unfoldAllMarkerRegions.label","Unfold All Regions"),alias:"Unfold All Regions",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2078),weight:100}})}invoke(e,t,i,s,n){if(t.regions.hasTypes())(0,m.cL)(t,g.lO.Region.value,!1);else{const e=i.getModel();if(!e)return;const s=n.getLanguageConfiguration(e.getLanguageId()).foldingRules;if(s&&s.markers&&s.markers.start){const e=new RegExp(s.markers.start);(0,m.AI)(t,e,!1)}}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.foldAllExcept",label:w.kg("foldAllExcept.label","Fold All Except Selected"),alias:"Fold All Except Selected",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2136),weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);(0,m.GR)(t,!0,s)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.unfoldAllExcept",label:w.kg("unfoldAllExcept.label","Unfold All Except Selected"),alias:"Unfold All Except Selected",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2134),weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);(0,m.GR)(t,!1,s)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.toggleFold",label:w.kg("toggleFoldAction.label","Toggle Fold"),alias:"Toggle Fold",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2090),weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);(0,m.bC)(t,1,s)}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.gotoParentFold",label:w.kg("gotoParentFold.label","Go to Parent Fold"),alias:"Go to Parent Fold",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);if(s.length>0){const e=(0,m.kK)(s[0],t);null!==e&&i.setSelection({startLineNumber:e,startColumn:1,endLineNumber:e,endColumn:1})}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.gotoPreviousFold",label:w.kg("gotoPreviousFold.label","Go to Previous Folding Range"),alias:"Go to Previous Folding Range",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);if(s.length>0){const e=(0,m.JX)(s[0],t);null!==e&&i.setSelection({startLineNumber:e,startColumn:1,endLineNumber:e,endColumn:1})}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.gotoNextFold",label:w.kg("gotoNextFold.label","Go to Next Folding Range"),alias:"Go to Next Folding Range",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,weight:100}})}invoke(e,t,i){const s=this.getSelectedLines(i);if(s.length>0){const e=(0,m.pr)(s[0],t);null!==e&&i.setSelection({startLineNumber:e,startColumn:1,endLineNumber:e,endColumn:1})}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.createFoldingRangeFromSelection",label:w.kg("createManualFoldRange.label","Create Folding Range from Selection"),alias:"Create Folding Range from Selection",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2135),weight:100}})}invoke(e,t,i){const s=[],n=i.getSelections();if(n){for(const e of n){let t=e.endLineNumber;1===e.endColumn&&--t,t>e.startLineNumber&&(s.push({startLineNumber:e.startLineNumber,endLineNumber:t,type:void 0,isCollapsed:!0,source:1}),i.setSelection({startLineNumber:e.startLineNumber,startColumn:1,endLineNumber:e.startLineNumber,endColumn:1}))}if(s.length>0){s.sort(((e,t)=>e.startLineNumber-t.startLineNumber));const e=T.tz.sanitizeAndMerge(t.regions,s,i.getModel()?.getLineCount());t.updatePost(T.tz.fromFoldRanges(e))}}}}),(0,d.Fl)(class extends V{constructor(){super({id:"editor.removeManualFoldingRanges",label:w.kg("removeManualFoldingRanges.label","Remove Manual Folding Ranges"),alias:"Remove Manual Folding Ranges",precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2137),weight:100}})}invoke(e,t,i){const s=i.getSelections();if(s){const i=[];for(const e of s){const{startLineNumber:t,endLineNumber:s}=e;i.push(s>=t?{startLineNumber:t,endLineNumber:s}:{endLineNumber:s,startLineNumber:t})}t.removeManualRanges(i),e.triggerFoldingModelChanged()}}});for(let j=1;j<=7;j++)(0,d.xX)(new G({id:G.ID(j),label:w.kg("foldLevelAction.label","Fold Level {0}",j),alias:`Fold Level ${j}`,precondition:H,kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2048|21+j),weight:100}}));O.w.registerCommand("_executeFoldingRangeProvider",(async function(e,...t){const[i]=t;if(!(i instanceof D.r))throw(0,r.Qg)();const s=e.get(I.ILanguageFeaturesService),o=e.get(M.IModelService).getModel(i);if(!o)throw(0,r.Qg)();const a=e.get(P.pG);if(!a.getValue("editor.folding",{resource:i}))return[];const l=e.get(p.JZ),c=a.getValue("editor.foldingStrategy",{resource:i}),h={get limit(){return a.getValue("editor.foldingMaximumRegions",{resource:i})},update:(e,t)=>{}},d=new y.hW(o,l,h);let u=d;if("indentation"!==c){const e=B.getFoldingRangeProviders(s,o);e.length&&(u=new x.M(o,e,(()=>{}),h,d))}const m=await u.compute(n.XO.None),f=[];try{if(m)for(let e=0;e{"use strict";i.d(t,{E0:()=>d,k0:()=>u,rv:()=>v});var s=i(10350),n=i(87289),r=i(78209),o=i(66261),a=i(61394),l=i(47612),c=i(25689);const h=(0,o.x1A)("editor.foldBackground",{light:(0,o.JO0)(o.seu,.3),dark:(0,o.JO0)(o.seu,.3),hcDark:null,hcLight:null},(0,r.kg)("foldBackgroundBackground","Background color behind folded ranges. The color must not be opaque so as not to hide underlying decorations."),!0);(0,o.x1A)("editor.foldPlaceholderForeground",{light:"#808080",dark:"#808080",hcDark:null,hcLight:null},(0,r.kg)("collapsedTextColor","Color of the collapsed text after the first line of a folded range.")),(0,o.x1A)("editorGutter.foldingControlForeground",o.t4B,(0,r.kg)("editorGutter.foldingControlForeground","Color of the folding control in the editor gutter."));const d=(0,a.pU)("folding-expanded",s.W.chevronDown,(0,r.kg)("foldingExpandedIcon","Icon for expanded ranges in the editor glyph margin.")),u=(0,a.pU)("folding-collapsed",s.W.chevronRight,(0,r.kg)("foldingCollapsedIcon","Icon for collapsed ranges in the editor glyph margin.")),g=(0,a.pU)("folding-manual-collapsed",u,(0,r.kg)("foldingManualCollapedIcon","Icon for manually collapsed ranges in the editor glyph margin.")),p=(0,a.pU)("folding-manual-expanded",d,(0,r.kg)("foldingManualExpandedIcon","Icon for manually expanded ranges in the editor glyph margin.")),m={color:(0,l.Yf)(h),position:1},f=(0,r.kg)("linesCollapsed","Click to expand the range."),_=(0,r.kg)("linesExpanded","Click to collapse the range.");class v{static{this.COLLAPSED_VISUAL_DECORATION=n.kI.register({description:"folding-collapsed-visual-decoration",stickiness:0,afterContentClassName:"inline-folded",isWholeLine:!0,linesDecorationsTooltip:f,firstLineDecorationClassName:c.L.asClassName(u)})}static{this.COLLAPSED_HIGHLIGHTED_VISUAL_DECORATION=n.kI.register({description:"folding-collapsed-highlighted-visual-decoration",stickiness:0,afterContentClassName:"inline-folded",className:"folded-background",minimap:m,isWholeLine:!0,linesDecorationsTooltip:f,firstLineDecorationClassName:c.L.asClassName(u)})}static{this.MANUALLY_COLLAPSED_VISUAL_DECORATION=n.kI.register({description:"folding-manually-collapsed-visual-decoration",stickiness:0,afterContentClassName:"inline-folded",isWholeLine:!0,linesDecorationsTooltip:f,firstLineDecorationClassName:c.L.asClassName(g)})}static{this.MANUALLY_COLLAPSED_HIGHLIGHTED_VISUAL_DECORATION=n.kI.register({description:"folding-manually-collapsed-highlighted-visual-decoration",stickiness:0,afterContentClassName:"inline-folded",className:"folded-background",minimap:m,isWholeLine:!0,linesDecorationsTooltip:f,firstLineDecorationClassName:c.L.asClassName(g)})}static{this.NO_CONTROLS_COLLAPSED_RANGE_DECORATION=n.kI.register({description:"folding-no-controls-range-decoration",stickiness:0,afterContentClassName:"inline-folded",isWholeLine:!0,linesDecorationsTooltip:f})}static{this.NO_CONTROLS_COLLAPSED_HIGHLIGHTED_RANGE_DECORATION=n.kI.register({description:"folding-no-controls-range-decoration",stickiness:0,afterContentClassName:"inline-folded",className:"folded-background",minimap:m,isWholeLine:!0,linesDecorationsTooltip:f})}static{this.EXPANDED_VISUAL_DECORATION=n.kI.register({description:"folding-expanded-visual-decoration",stickiness:1,isWholeLine:!0,firstLineDecorationClassName:"alwaysShowFoldIcons "+c.L.asClassName(d),linesDecorationsTooltip:_})}static{this.EXPANDED_AUTO_HIDE_VISUAL_DECORATION=n.kI.register({description:"folding-expanded-auto-hide-visual-decoration",stickiness:1,isWholeLine:!0,firstLineDecorationClassName:c.L.asClassName(d),linesDecorationsTooltip:_})}static{this.MANUALLY_EXPANDED_VISUAL_DECORATION=n.kI.register({description:"folding-manually-expanded-visual-decoration",stickiness:0,isWholeLine:!0,firstLineDecorationClassName:"alwaysShowFoldIcons "+c.L.asClassName(p),linesDecorationsTooltip:_})}static{this.MANUALLY_EXPANDED_AUTO_HIDE_VISUAL_DECORATION=n.kI.register({description:"folding-manually-expanded-auto-hide-visual-decoration",stickiness:0,isWholeLine:!0,firstLineDecorationClassName:c.L.asClassName(p),linesDecorationsTooltip:_})}static{this.NO_CONTROLS_EXPANDED_RANGE_DECORATION=n.kI.register({description:"folding-no-controls-range-decoration",stickiness:0,isWholeLine:!0})}static{this.HIDDEN_RANGE_DECORATION=n.kI.register({description:"folding-hidden-range-decoration",stickiness:1})}constructor(e){this.editor=e,this.showFoldingControls="mouseover",this.showFoldingHighlights=!0}getDecorationOption(e,t,i){return t?v.HIDDEN_RANGE_DECORATION:"never"===this.showFoldingControls?e?this.showFoldingHighlights?v.NO_CONTROLS_COLLAPSED_HIGHLIGHTED_RANGE_DECORATION:v.NO_CONTROLS_COLLAPSED_RANGE_DECORATION:v.NO_CONTROLS_EXPANDED_RANGE_DECORATION:e?i?this.showFoldingHighlights?v.MANUALLY_COLLAPSED_HIGHLIGHTED_VISUAL_DECORATION:v.MANUALLY_COLLAPSED_VISUAL_DECORATION:this.showFoldingHighlights?v.COLLAPSED_HIGHLIGHTED_VISUAL_DECORATION:v.COLLAPSED_VISUAL_DECORATION:"mouseover"===this.showFoldingControls?i?v.MANUALLY_EXPANDED_AUTO_HIDE_VISUAL_DECORATION:v.EXPANDED_AUTO_HIDE_VISUAL_DECORATION:i?v.MANUALLY_EXPANDED_VISUAL_DECORATION:v.EXPANDED_VISUAL_DECORATION}changeDecorations(e){return this.editor.changeDecorations(e)}removeDecorations(e){this.editor.removeDecorations(e)}}},52903:(e,t,i)=>{"use strict";i.d(t,{AI:()=>g,GR:()=>u,JX:()=>f,W8:()=>h,bC:()=>a,cL:()=>p,dN:()=>c,kK:()=>m,pN:()=>o,pr:()=>_,sO:()=>d,uV:()=>l});var s=i(41234),n=i(44026),r=i(85600);class o{get regions(){return this._regions}get textModel(){return this._textModel}constructor(e,t){this._updateEventEmitter=new s.vl,this.onDidChange=this._updateEventEmitter.event,this._textModel=e,this._decorationProvider=t,this._regions=new n.tz(new Uint32Array(0),new Uint32Array(0)),this._editorDecorationIds=[]}toggleCollapseState(e){if(!e.length)return;e=e.sort(((e,t)=>e.regionIndex-t.regionIndex));const t={};this._decorationProvider.changeDecorations((i=>{let s=0,n=-1,r=-1;const o=e=>{for(;sr&&(r=e),s++}};for(const a of e){const e=a.regionIndex,i=this._editorDecorationIds[e];if(i&&!t[i]){t[i]=!0,o(e);const s=!this._regions.isCollapsed(e);this._regions.setCollapsed(e,s),n=Math.max(n,this._regions.getEndLineNumber(e))}}o(this._regions.length)})),this._updateEventEmitter.fire({model:this,collapseStateChanged:e})}removeManualRanges(e){const t=new Array,i=t=>{for(const i of e)if(!(i.startLineNumber>t.endLineNumber||t.startLineNumber>i.endLineNumber))return!0;return!1};for(let s=0;si&&(i=r)}this._decorationProvider.changeDecorations((e=>this._editorDecorationIds=e.deltaDecorations(this._editorDecorationIds,t))),this._regions=e,this._updateEventEmitter.fire({model:this})}_currentFoldedOrManualRanges(e){const t=[];for(let i=0,s=this._regions.length;i=n.endLineNumber||n.startLineNumber<1||n.endLineNumber>i)continue;const r=this._getLinesChecksum(n.startLineNumber+1,n.endLineNumber);t.push({startLineNumber:n.startLineNumber,endLineNumber:n.endLineNumber,isCollapsed:n.isCollapsed,source:n.source,checksum:r})}return t.length>0?t:void 0}applyMemento(e){if(!Array.isArray(e))return;const t=[],i=this._textModel.getLineCount();for(const n of e){if(n.startLineNumber>=n.endLineNumber||n.startLineNumber<1||n.endLineNumber>i)continue;const e=this._getLinesChecksum(n.startLineNumber+1,n.endLineNumber);n.checksum&&e!==n.checksum||t.push({startLineNumber:n.startLineNumber,endLineNumber:n.endLineNumber,type:void 0,isCollapsed:n.isCollapsed??!0,source:n.source??0})}const s=n.tz.sanitizeAndMerge(this._regions,t,i);this.updatePost(n.tz.fromFoldRanges(s))}_getLinesChecksum(e,t){return(0,r.tW)(this._textModel.getLineContent(e)+this._textModel.getLineContent(t))%1e6}dispose(){this._decorationProvider.removeDecorations(this._editorDecorationIds)}getAllRegionsAtLine(e,t){const i=[];if(this._regions){let s=this._regions.findRange(e),n=1;for(;s>=0;){const e=this._regions.toRegion(s);t&&!t(e,n)||i.push(e),n++,s=e.parentIndex}}return i}getRegionAtLine(e){if(this._regions){const t=this._regions.findRange(e);if(t>=0)return this._regions.toRegion(t)}return null}getRegionsInside(e,t){const i=[],s=e?e.regionIndex+1:0,n=e?e.endLineNumber:Number.MAX_VALUE;if(t&&2===t.length){const e=[];for(let r=s,o=this._regions.length;r0&&!s.containedBy(e[e.length-1]);)e.pop();e.push(s),t(s,e.length)&&i.push(s)}}else for(let r=s,o=this._regions.length;r1){const r=e.getRegionsInside(i,((e,i)=>e.isCollapsed!==n&&i0)for(const r of s){const s=e.getRegionAtLine(r);if(s&&(s.isCollapsed!==t&&n.push(s),i>1)){const r=e.getRegionsInside(s,((e,s)=>e.isCollapsed!==t&&se.isCollapsed!==t&&se.isCollapsed!==t&&s<=i));n.push(...s)}e.toggleCollapseState(n)}function h(e,t,i){const s=[];for(const n of i){const i=e.getAllRegionsAtLine(n,(e=>e.isCollapsed!==t));i.length>0&&s.push(i[0])}e.toggleCollapseState(s)}function d(e,t,i,s){const n=e.getRegionsInside(null,((e,n)=>n===t&&e.isCollapsed!==i&&!s.some((t=>e.containsLine(t)))));e.toggleCollapseState(n)}function u(e,t,i){const s=[];for(const r of i){const t=e.getAllRegionsAtLine(r,void 0);t.length>0&&s.push(t[0])}const n=e.getRegionsInside(null,(e=>s.every((t=>!t.containedBy(e)&&!e.containedBy(t)))&&e.isCollapsed!==t));e.toggleCollapseState(n)}function g(e,t,i){const s=e.textModel,n=e.regions,r=[];for(let o=n.length-1;o>=0;o--)if(i!==n.isCollapsed(o)){const e=n.getStartLineNumber(o);t.test(s.getLineContent(e))&&r.push(n.toRegion(o))}e.toggleCollapseState(r)}function p(e,t,i){const s=e.regions,n=[];for(let r=s.length-1;r>=0;r--)i!==s.isCollapsed(r)&&t===s.getType(r)&&n.push(s.toRegion(r));e.toggleCollapseState(n)}function m(e,t){let i=null;const s=t.getRegionAtLine(e);if(null!==s&&(i=s.startLineNumber,e===i)){const e=s.parentIndex;i=-1!==e?t.regions.getStartLineNumber(e):null}return i}function f(e,t){let i=t.getRegionAtLine(e);if(null!==i&&i.startLineNumber===e){if(e!==i.startLineNumber)return i.startLineNumber;{const e=i.parentIndex;let s=0;for(-1!==e&&(s=t.regions.getStartLineNumber(i.parentIndex));null!==i;){if(!(i.regionIndex>0))return null;if(i=t.regions.toRegion(i.regionIndex-1),i.startLineNumber<=s)return null;if(i.parentIndex===e)return i.startLineNumber}}}else if(t.regions.length>0)for(i=t.regions.toRegion(t.regions.length-1);null!==i;){if(i.startLineNumber0?t.regions.toRegion(i.regionIndex-1):null}return null}function _(e,t){let i=t.getRegionAtLine(e);if(null!==i&&i.startLineNumber===e){const e=i.parentIndex;let s=0;if(-1!==e)s=t.regions.getEndLineNumber(i.parentIndex);else{if(0===t.regions.length)return null;s=t.regions.getEndLineNumber(t.regions.length-1)}for(;null!==i;){if(!(i.regionIndex=s)return null;if(i.parentIndex===e)return i.startLineNumber}}else if(t.regions.length>0)for(i=t.regions.toRegion(0);null!==i;){if(i.startLineNumber>e)return i.startLineNumber;i=i.regionIndex{"use strict";i.d(t,{tz:()=>a,yy:()=>n});const s={0:" ",1:"u",2:"r"},n=16777215,r=4278190080;class o{constructor(e){const t=Math.ceil(e/32);this._states=new Uint32Array(t)}get(e){const t=e/32|0,i=e%32;return 0!==(this._states[t]&1<65535)throw new Error("invalid startIndexes or endIndexes size");this._startIndexes=e,this._endIndexes=t,this._collapseStates=new o(e.length),this._userDefinedStates=new o(e.length),this._recoveredStates=new o(e.length),this._types=i,this._parentsComputed=!1}ensureParentIndices(){if(!this._parentsComputed){this._parentsComputed=!0;const e=[],t=(t,i)=>{const s=e[e.length-1];return this.getStartLineNumber(s)<=t&&this.getEndLineNumber(s)>=i};for(let i=0,s=this._startIndexes.length;in||r>n)throw new Error("startLineNumber or endLineNumber must not exceed "+n);for(;e.length>0&&!t(s,r);)e.pop();const o=e.length>0?e[e.length-1]:-1;e.push(i),this._startIndexes[i]=s+((255&o)<<24),this._endIndexes[i]=r+((65280&o)<<16)}}}get length(){return this._startIndexes.length}getStartLineNumber(e){return this._startIndexes[e]&n}getEndLineNumber(e){return this._endIndexes[e]&n}getType(e){return this._types?this._types[e]:void 0}hasTypes(){return!!this._types}isCollapsed(e){return this._collapseStates.get(e)}setCollapsed(e,t){this._collapseStates.set(e,t)}isUserDefined(e){return this._userDefinedStates.get(e)}setUserDefined(e,t){return this._userDefinedStates.set(e,t)}isRecovered(e){return this._recoveredStates.get(e)}setRecovered(e,t){return this._recoveredStates.set(e,t)}getSource(e){return this.isUserDefined(e)?1:this.isRecovered(e)?2:0}setSource(e,t){1===t?(this.setUserDefined(e,!0),this.setRecovered(e,!1)):2===t?(this.setUserDefined(e,!1),this.setRecovered(e,!0)):(this.setUserDefined(e,!1),this.setRecovered(e,!1))}setCollapsedAllOfType(e,t){let i=!1;if(this._types)for(let s=0;s>>24)+((this._endIndexes[e]&r)>>>16);return 65535===t?-1:t}contains(e,t){return this.getStartLineNumber(e)<=t&&this.getEndLineNumber(e)>=t}findIndex(e){let t=0,i=this._startIndexes.length;if(0===i)return-1;for(;t=0){if(this.getEndLineNumber(t)>=e)return t;for(t=this.getParentIndex(t);-1!==t;){if(this.contains(t,e))return t;t=this.getParentIndex(t)}}return-1}toString(){const e=[];for(let t=0;tArray.isArray(e)?i=>ii=h.startLineNumber))c&&c.startLineNumber===h.startLineNumber?(1===h.source?e=h:(e=c,e.isCollapsed=h.isCollapsed&&(c.endLineNumber===h.endLineNumber||!s?.startsInside(c.startLineNumber+1,c.endLineNumber+1)),e.source=0),c=r(++a)):(e=h,h.isCollapsed&&0===h.source&&(e.source=2)),h=o(++l);else{let t=l,i=h;for(;;){if(!i||i.startLineNumber>c.endLineNumber){e=c;break}if(1===i.source&&i.endLineNumber>c.endLineNumber)break;i=o(++t)}c=r(++a)}if(e){for(;u&&u.endLineNumbere.startLineNumber&&e.startLineNumber>g&&e.endLineNumber<=i&&(!u||u.endLineNumber>=e.endLineNumber)&&(p.push(e),g=e.startLineNumber,u&&d.push(u),u=e)}}return p}}class l{constructor(e,t){this.ranges=e,this.index=t}get startLineNumber(){return this.ranges.getStartLineNumber(this.index)}get endLineNumber(){return this.ranges.getEndLineNumber(this.index)}get regionIndex(){return this.index}get parentIndex(){return this.ranges.getParentIndex(this.index)}get isCollapsed(){return this.ranges.isCollapsed(this.index)}containedBy(e){return e.startLineNumber<=this.startLineNumber&&e.endLineNumber>=this.endLineNumber}containsLine(e){return this.startLineNumber<=e&&e<=this.endLineNumber}}},76495:(e,t,i)=>{"use strict";i.d(t,{hW:()=>r});var s=i(78049),n=i(44026);class r{constructor(e,t,i){this.editorModel=e,this.languageConfigurationService=t,this.foldingRangesLimit=i,this.id="indent"}dispose(){}compute(e){const t=this.languageConfigurationService.getLanguageConfiguration(this.editorModel.getLanguageId()).foldingRules,i=t&&!!t.offSide,n=t&&t.markers;return Promise.resolve(function(e,t,i,n=a){const r=e.getOptions().tabSize,l=new o(n);let c;i&&(c=new RegExp(`(${i.start.source})|(?:${i.end.source})`));const h=[],d=e.getLineCount()+1;h.push({indent:-1,endAbove:d,line:d});for(let o=e.getLineCount();o>0;o--){const i=e.getLineContent(o),n=(0,s.G)(i,r);let a,d=h[h.length-1];if(-1!==n){if(c&&(a=i.match(c))){if(!a[1]){h.push({indent:-2,endAbove:o,line:o});continue}{let e=h.length-1;for(;e>0&&-2!==h[e].indent;)e--;if(e>0){h.length=e+1,d=h[e],l.insertFirst(o,d.line,n),d.line=o,d.indent=n,d.endAbove=o;continue}}}if(d.indent>n){do{h.pop(),d=h[h.length-1]}while(d.indent>n);const e=d.endAbove-1;e-o>=1&&l.insertFirst(o,e,n)}d.indent===n?d.endAbove=o:h.push({indent:n,endAbove:o,line:o})}else t&&(d.endAbove=o)}return l.toIndentRanges(e)}(this.editorModel,i,n,this.foldingRangesLimit))}}class o{constructor(e){this._startIndexes=[],this._endIndexes=[],this._indentOccurrences=[],this._length=0,this._foldingRangesLimit=e}insertFirst(e,t,i){if(e>n.yy||t>n.yy)return;const s=this._length;this._startIndexes[s]=e,this._endIndexes[s]=t,this._length++,i<1e3&&(this._indentOccurrences[i]=(this._indentOccurrences[i]||0)+1)}toIndentRanges(e){const t=this._foldingRangesLimit.limit;if(this._length<=t){this._foldingRangesLimit.update(this._length,!1);const e=new Uint32Array(this._length),t=new Uint32Array(this._length);for(let i=this._length-1,s=0;i>=0;i--,s++)e[s]=this._startIndexes[i],t[s]=this._endIndexes[i];return new n.tz(e,t)}{this._foldingRangesLimit.update(this._length,t);let i=0,r=this._indentOccurrences.length;for(let e=0;et){r=e;break}i+=s}}const o=e.getOptions().tabSize,a=new Uint32Array(t),l=new Uint32Array(t);for(let n=this._length-1,c=0;n>=0;n--){const h=this._startIndexes[n],d=e.getLineContent(h),u=(0,s.G)(d,o);(u{}}},87784:(e,t,i)=>{"use strict";i.d(t,{M:()=>a});var s=i(64383),n=i(5662),r=i(44026);const o={};class a{constructor(e,t,i,s,r){this.editorModel=e,this.providers=t,this.handleFoldingRangesChange=i,this.foldingRangesLimit=s,this.fallbackRangeProvider=r,this.id="syntax",this.disposables=new n.Cm,r&&this.disposables.add(r);for(const n of t)"function"===typeof n.onDidChange&&this.disposables.add(n.onDidChange(i))}compute(e){return function(e,t,i){let n=null;const r=e.map(((e,r)=>Promise.resolve(e.provideFoldingRanges(t,o,i)).then((e=>{if(!i.isCancellationRequested&&Array.isArray(e)){Array.isArray(n)||(n=[]);const i=t.getLineCount();for(const t of e)t.start>0&&t.end>t.start&&t.end<=i&&n.push({start:t.start,end:t.end,rank:r,kind:t.kind})}}),s.M_)));return Promise.all(r).then((e=>n))}(this.providers,this.editorModel,e).then((t=>{if(t){return function(e,t){const i=e.sort(((e,t)=>{let i=e.start-t.start;return 0===i&&(i=e.rank-t.rank),i})),s=new l(t);let n;const r=[];for(const o of i)if(n){if(o.start>n.start)if(o.end<=n.end)r.push(n),n=o,s.add(o.start,o.end,o.kind&&o.kind.value,r.length);else{if(o.start>n.end){do{n=r.pop()}while(n&&o.start>n.end);n&&r.push(n),n=o}s.add(o.start,o.end,o.kind&&o.kind.value,r.length)}}else n=o,s.add(o.start,o.end,o.kind&&o.kind.value,r.length);return s.toIndentRanges()}(t,this.foldingRangesLimit)}return this.fallbackRangeProvider?.compute(e)??null}))}dispose(){this.disposables.dispose()}}class l{constructor(e){this._startIndexes=[],this._endIndexes=[],this._nestingLevels=[],this._nestingLevelCounts=[],this._types=[],this._length=0,this._foldingRangesLimit=e}add(e,t,i,s){if(e>r.yy||t>r.yy)return;const n=this._length;this._startIndexes[n]=e,this._endIndexes[n]=t,this._nestingLevels[n]=s,this._types[n]=i,this._length++,s<30&&(this._nestingLevelCounts[s]=(this._nestingLevelCounts[s]||0)+1)}toIndentRanges(){const e=this._foldingRangesLimit.limit;if(this._length<=e){this._foldingRangesLimit.update(this._length,!1);const e=new Uint32Array(this._length),t=new Uint32Array(this._length);for(let i=0;ie){i=r;break}t+=s}}const s=new Uint32Array(e),n=new Uint32Array(e),o=[];for(let r=0,a=0;r{"use strict";var s=i(31450),n=i(79027),r=i(78209);class o extends s.ks{constructor(){super({id:"editor.action.fontZoomIn",label:r.kg("EditorFontZoomIn.label","Increase Editor Font Size"),alias:"Increase Editor Font Size",precondition:void 0})}run(e,t){n.D.setZoomLevel(n.D.getZoomLevel()+1)}}class a extends s.ks{constructor(){super({id:"editor.action.fontZoomOut",label:r.kg("EditorFontZoomOut.label","Decrease Editor Font Size"),alias:"Decrease Editor Font Size",precondition:void 0})}run(e,t){n.D.setZoomLevel(n.D.getZoomLevel()-1)}}class l extends s.ks{constructor(){super({id:"editor.action.fontZoomReset",label:r.kg("EditorFontZoomReset.label","Reset Editor Font Size"),alias:"Reset Editor Font Size",precondition:void 0})}run(e,t){n.D.setZoomLevel(0)}}(0,s.Fl)(o),(0,s.Fl)(a),(0,s.Fl)(l)},49079:(e,t,i)=>{"use strict";i.d(t,{Pj:()=>R,jX:()=>T,vg:()=>k,_V:()=>N});var s=i(25890),n=i(18447),r=i(64383),o=i(42522),a=i(58925),l=i(631),c=i(79400),h=i(50868),d=i(34326),u=i(83069),g=i(36677),p=i(75326),m=i(10920),f=i(18938),_=i(36998),v=i(50091);class C{constructor(e){this.value=e,this._lower=e.toLowerCase()}static toKey(e){return"string"===typeof e?e.toLowerCase():e._lower}}class b{constructor(e){if(this._set=new Set,e)for(const t of e)this.add(t)}add(e){this._set.add(C.toKey(e))}has(e){return this._set.has(C.toKey(e))}}var E=i(63591),S=i(56942),y=i(18801),w=i(87213);function L(e,t,i){const s=[],n=new b,r=e.ordered(i);for(const a of r)s.push(a),a.extensionId&&n.add(a.extensionId);const o=t.ordered(i);for(const a of o){if(a.extensionId){if(n.has(a.extensionId))continue;n.add(a.extensionId)}s.push({displayName:a.displayName,extensionId:a.extensionId,provideDocumentFormattingEdits:(e,t,i)=>a.provideDocumentRangeFormattingEdits(e,e.getFullModelRange(),t,i)})}return s}class R{static{this._selectors=new a.w}static setFormatterSelector(e){return{dispose:R._selectors.unshift(e)}}static async select(e,t,i,s){if(0===e.length)return;const n=o.f.first(R._selectors);return n?await n(e,t,i,s):void 0}}async function T(e,t,i,s,n,r,o){const a=e.get(E._Y),{documentRangeFormattingEditProvider:l}=e.get(S.ILanguageFeaturesService),c=(0,d.z9)(t)?t.getModel():t,h=l.ordered(c),u=await R.select(h,c,s,2);u&&(n.report(u),await a.invokeFunction(x,u,t,i,r,o))}async function x(e,t,i,n,r,o){const a=e.get(m.IEditorWorkerService),l=e.get(y.rr),c=e.get(w.Nt);let u,f;(0,d.z9)(i)?(u=i.getModel(),f=new h.gI(i,5,void 0,r)):(u=i,f=new h.ER(i,r));const v=[];let C=0;for(const h of(0,s._j)(n).sort(g.Q.compareRangesUsingStarts))C>0&&g.Q.areIntersectingOrTouching(v[C-1],h)?v[C-1]=g.Q.fromPositions(v[C-1].getStartPosition(),h.getEndPosition()):C=v.push(h);const b=async e=>{l.trace("[format][provideDocumentRangeFormattingEdits] (request)",t.extensionId?.value,e);const i=await t.provideDocumentRangeFormattingEdits(u,e,u.getFormattingOptions(),f.token)||[];return l.trace("[format][provideDocumentRangeFormattingEdits] (response)",t.extensionId?.value,i),i},E=(e,t)=>{if(!e.length||!t.length)return!1;const i=e.reduce(((e,t)=>g.Q.plusRange(e,t.range)),e[0].range);if(!t.some((e=>g.Q.intersectRanges(i,e.range))))return!1;for(const s of e)for(const e of t)if(g.Q.intersectRanges(s.range,e.range))return!0;return!1},S=[],L=[];try{if("function"===typeof t.provideDocumentRangesFormattingEdits){l.trace("[format][provideDocumentRangeFormattingEdits] (request)",t.extensionId?.value,v);const e=await t.provideDocumentRangesFormattingEdits(u,v,u.getFormattingOptions(),f.token)||[];l.trace("[format][provideDocumentRangeFormattingEdits] (response)",t.extensionId?.value,e),L.push(e)}else{for(const e of v){if(f.token.isCancellationRequested)return!0;L.push(await b(e))}for(let e=0;e({text:e.text,range:g.Q.lift(e.range),forceMoveMarkers:!0}))),(e=>{for(const{range:i}of e)if(g.Q.areIntersectingOrTouching(i,t))return[new p.L(i.startLineNumber,i.startColumn,i.endLineNumber,i.endColumn)];return null}))}return c.playSignal(w.Rh.format,{userGesture:o}),!0}async function k(e,t,i,s,n,r){const o=e.get(E._Y),a=e.get(S.ILanguageFeaturesService),l=(0,d.z9)(t)?t.getModel():t,c=L(a.documentFormattingEditProvider,a.documentRangeFormattingEditProvider,l),h=await R.select(c,l,i,1);h&&(s.report(h),await o.invokeFunction(A,h,t,i,n,r))}async function A(e,t,i,s,n,r){const o=e.get(m.IEditorWorkerService),a=e.get(w.Nt);let l,c,u;(0,d.z9)(i)?(l=i.getModel(),c=new h.gI(i,5,void 0,n)):(l=i,c=new h.ER(i,n));try{const e=await t.provideDocumentFormattingEdits(l,l.getFormattingOptions(),c.token);if(u=await o.computeMoreMinimalEdits(l.uri,e),c.token.isCancellationRequested)return!0}finally{c.dispose()}if(!u||0===u.length)return!1;if((0,d.z9)(i))_.c.execute(i,u,2!==s),2!==s&&i.revealPositionInCenterIfOutsideViewport(i.getPosition(),1);else{const[{range:e}]=u,t=new p.L(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn);l.pushEditOperations([t],u.map((e=>({text:e.text,range:g.Q.lift(e.range),forceMoveMarkers:!0}))),(e=>{for(const{range:i}of e)if(g.Q.areIntersectingOrTouching(i,t))return[new p.L(i.startLineNumber,i.startColumn,i.endLineNumber,i.endColumn)];return null}))}return a.playSignal(w.Rh.format,{userGesture:r}),!0}function N(e,t,i,s,n,o,a){const l=t.onTypeFormattingEditProvider.ordered(i);return 0===l.length||l[0].autoFormatTriggerCharacters.indexOf(n)<0?Promise.resolve(void 0):Promise.resolve(l[0].provideOnTypeFormattingEdits(i,s,n,o,a)).catch(r.M_).then((t=>e.computeMoreMinimalEdits(i.uri,t)))}v.w.registerCommand("_executeFormatRangeProvider",(async function(e,...t){const[i,o,a]=t;(0,l.j)(c.r.isUri(i)),(0,l.j)(g.Q.isIRange(o));const h=e.get(f.ITextModelService),d=e.get(m.IEditorWorkerService),u=e.get(S.ILanguageFeaturesService),p=await h.createModelReference(i);try{return async function(e,t,i,n,o,a){const l=t.documentRangeFormattingEditProvider.ordered(i);for(const c of l){const t=await Promise.resolve(c.provideDocumentRangeFormattingEdits(i,n,o,a)).catch(r.M_);if((0,s.EI)(t))return await e.computeMoreMinimalEdits(i.uri,t)}}(d,u,p.object.textEditorModel,g.Q.lift(o),a,n.XO.None)}finally{p.dispose()}})),v.w.registerCommand("_executeFormatDocumentProvider",(async function(e,...t){const[i,o]=t;(0,l.j)(c.r.isUri(i));const a=e.get(f.ITextModelService),h=e.get(m.IEditorWorkerService),d=e.get(S.ILanguageFeaturesService),u=await a.createModelReference(i);try{return async function(e,t,i,n,o){const a=L(t.documentFormattingEditProvider,t.documentRangeFormattingEditProvider,i);for(const l of a){const t=await Promise.resolve(l.provideDocumentFormattingEdits(i,n,o)).catch(r.M_);if((0,s.EI)(t))return await e.computeMoreMinimalEdits(i.uri,t)}}(h,d,u.object.textEditorModel,o,n.XO.None)}finally{u.dispose()}})),v.w.registerCommand("_executeFormatOnTypeProvider",(async function(e,...t){const[i,s,r,o]=t;(0,l.j)(c.r.isUri(i)),(0,l.j)(u.y.isIPosition(s)),(0,l.j)("string"===typeof r);const a=e.get(f.ITextModelService),h=e.get(m.IEditorWorkerService),d=e.get(S.ILanguageFeaturesService),g=await a.createModelReference(i);try{return N(h,d,g.object.textEditorModel,u.y.lift(s),r,o,n.XO.None)}finally{g.dispose()}}))},48279:(e,t,i)=>{"use strict";var s=i(25890),n=i(18447),r=i(64383),o=i(24939),a=i(5662),l=i(31450),c=i(80301),h=i(60534),d=i(36677),u=i(60002),g=i(10920),p=i(56942),m=i(49079),f=i(36998),_=i(78209),v=i(87213),C=i(50091),b=i(32848),E=i(63591),S=i(73823),y=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},w=function(e,t){return function(i,s){t(i,s,e)}};let L=class{static{this.ID="editor.contrib.autoFormat"}constructor(e,t,i,s){this._editor=e,this._languageFeaturesService=t,this._workerService=i,this._accessibilitySignalService=s,this._disposables=new a.Cm,this._sessionDisposables=new a.Cm,this._disposables.add(t.onTypeFormattingEditProvider.onDidChange(this._update,this)),this._disposables.add(e.onDidChangeModel((()=>this._update()))),this._disposables.add(e.onDidChangeModelLanguage((()=>this._update()))),this._disposables.add(e.onDidChangeConfiguration((e=>{e.hasChanged(56)&&this._update()}))),this._update()}dispose(){this._disposables.dispose(),this._sessionDisposables.dispose()}_update(){if(this._sessionDisposables.clear(),!this._editor.getOption(56))return;if(!this._editor.hasModel())return;const e=this._editor.getModel(),[t]=this._languageFeaturesService.onTypeFormattingEditProvider.ordered(e);if(!t||!t.autoFormatTriggerCharacters)return;const i=new h.y;for(const s of t.autoFormatTriggerCharacters)i.add(s.charCodeAt(0));this._sessionDisposables.add(this._editor.onDidType((e=>{const t=e.charCodeAt(e.length-1);i.has(t)&&this._trigger(String.fromCharCode(t))})))}_trigger(e){if(!this._editor.hasModel())return;if(this._editor.getSelections().length>1||!this._editor.getSelection().isEmpty())return;const t=this._editor.getModel(),i=this._editor.getPosition(),r=new n.Qi,o=this._editor.onDidChangeModelContent((e=>{if(e.isFlush)return r.cancel(),void o.dispose();for(let t=0,s=e.changes.length;t{r.token.isCancellationRequested||(0,s.EI)(e)&&(this._accessibilitySignalService.playSignal(v.Rh.format,{userGesture:!1}),f.c.execute(this._editor,e,!0))})).finally((()=>{o.dispose()}))}};L=y([w(1,p.ILanguageFeaturesService),w(2,g.IEditorWorkerService),w(3,v.Nt)],L);let R=class{static{this.ID="editor.contrib.formatOnPaste"}constructor(e,t,i){this.editor=e,this._languageFeaturesService=t,this._instantiationService=i,this._callOnDispose=new a.Cm,this._callOnModel=new a.Cm,this._callOnDispose.add(e.onDidChangeConfiguration((()=>this._update()))),this._callOnDispose.add(e.onDidChangeModel((()=>this._update()))),this._callOnDispose.add(e.onDidChangeModelLanguage((()=>this._update()))),this._callOnDispose.add(t.documentRangeFormattingEditProvider.onDidChange(this._update,this))}dispose(){this._callOnDispose.dispose(),this._callOnModel.dispose()}_update(){this._callOnModel.clear(),this.editor.getOption(55)&&this.editor.hasModel()&&this._languageFeaturesService.documentRangeFormattingEditProvider.has(this.editor.getModel())&&this._callOnModel.add(this.editor.onDidPaste((({range:e})=>this._trigger(e))))}_trigger(e){this.editor.hasModel()&&(this.editor.getSelections().length>1||this._instantiationService.invokeFunction(m.jX,this.editor,e,2,S.ke.None,n.XO.None,!1).catch(r.dz))}};R=y([w(1,p.ILanguageFeaturesService),w(2,E._Y)],R);class T extends l.ks{constructor(){super({id:"editor.action.formatDocument",label:_.kg("formatDocument.label","Format Document"),alias:"Format Document",precondition:b.M$.and(u.R.notInCompositeEditor,u.R.writable,u.R.hasDocumentFormattingProvider),kbOpts:{kbExpr:u.R.editorTextFocus,primary:1572,linux:{primary:3111},weight:100},contextMenuOpts:{group:"1_modification",order:1.3}})}async run(e,t){if(t.hasModel()){const i=e.get(E._Y),s=e.get(S.N8);await s.showWhile(i.invokeFunction(m.vg,t,1,S.ke.None,n.XO.None,!0),250)}}}class x extends l.ks{constructor(){super({id:"editor.action.formatSelection",label:_.kg("formatSelection.label","Format Selection"),alias:"Format Selection",precondition:b.M$.and(u.R.writable,u.R.hasDocumentSelectionFormattingProvider),kbOpts:{kbExpr:u.R.editorTextFocus,primary:(0,o.m5)(2089,2084),weight:100},contextMenuOpts:{when:u.R.hasNonEmptySelection,group:"1_modification",order:1.31}})}async run(e,t){if(!t.hasModel())return;const i=e.get(E._Y),s=t.getModel(),r=t.getSelections().map((e=>e.isEmpty()?new d.Q(e.startLineNumber,1,e.startLineNumber,s.getLineMaxColumn(e.startLineNumber)):e)),o=e.get(S.N8);await o.showWhile(i.invokeFunction(m.jX,t,r,1,S.ke.None,n.XO.None,!0),250)}}(0,l.HW)(L.ID,L,2),(0,l.HW)(R.ID,R,2),(0,l.Fl)(T),(0,l.Fl)(x),C.w.registerCommand("editor.action.format",(async e=>{const t=e.get(c.T).getFocusedCodeEditor();if(!t||!t.hasModel())return;const i=e.get(C.d);t.getSelection().isEmpty()?await i.executeCommand("editor.action.formatDocument"):await i.executeCommand("editor.action.formatSelection")}))},36998:(e,t,i)=>{"use strict";i.d(t,{c:()=>o});var s=i(7085),n=i(36677),r=i(55190);class o{static _handleEolEdits(e,t){let i;const s=[];for(const n of t)"number"===typeof n.eol&&(i=n.eol),n.range&&"string"===typeof n.text&&s.push(n);return"number"===typeof i&&e.hasModel()&&e.getModel().pushEOL(i),s}static _isFullModelReplaceEdit(e,t){if(!e.hasModel())return!1;const i=e.getModel(),s=i.validateRange(t.range);return i.getFullModelRange().equalsRange(s)}static execute(e,t,i){i&&e.pushUndoStop();const a=r.D.capture(e),l=o._handleEolEdits(e,t);1===l.length&&o._isFullModelReplaceEdit(e,l[0])?e.executeEdits("formatEditsCommand",l.map((e=>s.k.replace(n.Q.lift(e.range),e.text)))):e.executeEdits("formatEditsCommand",l.map((e=>s.k.replaceMove(n.Q.lift(e.range),e.text)))),i&&e.pushUndoStop(),a.restoreRelativeVerticalPositionOfCursor(e)}}},65877:(e,t,i)=>{"use strict";i.d(t,{j:()=>oe,i:()=>le});var s=i(10350),n=i(5662),r=i(31450),o=i(80301),a=i(83069),l=i(36677),c=i(60002),h=i(25890),d=i(41234),u=i(58925),g=i(91508),p=i(79400),m=i(14718),f=i(63591),_=i(75147),v=i(84001),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},b=function(e,t){return function(i,s){t(i,s,e)}};class E{constructor(e,t,i){this.marker=e,this.index=t,this.total=i}}let S=class{constructor(e,t,i){this._markerService=t,this._configService=i,this._onDidChange=new d.vl,this.onDidChange=this._onDidChange.event,this._dispoables=new n.Cm,this._markers=[],this._nextIdx=-1,p.r.isUri(e)?this._resourceFilter=t=>t.toString()===e.toString():e&&(this._resourceFilter=e);const s=this._configService.getValue("problems.sortOrder"),r=(e,t)=>{let i=(0,g.UD)(e.resource.toString(),t.resource.toString());return 0===i&&(i="position"===s?l.Q.compareRangesUsingStarts(e,t)||_.cj.compare(e.severity,t.severity):_.cj.compare(e.severity,t.severity)||l.Q.compareRangesUsingStarts(e,t)),i},o=()=>{this._markers=this._markerService.read({resource:p.r.isUri(e)?e:void 0,severities:_.cj.Error|_.cj.Warning|_.cj.Info}),"function"===typeof e&&(this._markers=this._markers.filter((e=>this._resourceFilter(e.resource)))),this._markers.sort(r)};o(),this._dispoables.add(t.onMarkerChanged((e=>{this._resourceFilter&&!e.some((e=>this._resourceFilter(e)))||(o(),this._nextIdx=-1,this._onDidChange.fire())})))}dispose(){this._dispoables.dispose(),this._onDidChange.dispose()}matches(e){return!this._resourceFilter&&!e||!(!this._resourceFilter||!e)&&this._resourceFilter(e)}get selected(){const e=this._markers[this._nextIdx];return e&&new E(e,this._nextIdx+1,this._markers.length)}_initIdx(e,t,i){let s=!1,n=this._markers.findIndex((t=>t.resource.toString()===e.uri.toString()));n<0&&(n=(0,h.El)(this._markers,{resource:e.uri},((e,t)=>(0,g.UD)(e.resource.toString(),t.resource.toString()))),n<0&&(n=~n));for(let r=n;rt.resource.toString()===e.toString()));if(!(i<0))for(;i=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},G=function(e,t){return function(i,s){t(i,s,e)}};class j{constructor(e,t,i,s,r){this._openerService=s,this._labelService=r,this._lines=0,this._longestLineLength=0,this._relatedDiagnostics=new WeakMap,this._disposables=new n.Cm,this._editor=t;const o=document.createElement("div");o.className="descriptioncontainer",this._messageBlock=document.createElement("div"),this._messageBlock.classList.add("message"),this._messageBlock.setAttribute("aria-live","assertive"),this._messageBlock.setAttribute("role","alert"),o.appendChild(this._messageBlock),this._relatedBlock=document.createElement("div"),o.appendChild(this._relatedBlock),this._disposables.add(A.b2(this._relatedBlock,"click",(e=>{e.preventDefault();const t=this._relatedDiagnostics.get(e.target);t&&i(t)}))),this._scrollable=new N.Se(o,{horizontal:1,vertical:1,useShadows:!1,horizontalScrollbarSize:6,verticalScrollbarSize:6}),e.appendChild(this._scrollable.getDomNode()),this._disposables.add(this._scrollable.onScroll((e=>{o.style.left=`-${e.scrollLeft}px`,o.style.top=`-${e.scrollTop}px`}))),this._disposables.add(this._scrollable)}dispose(){(0,n.AS)(this._disposables)}update(e){const{source:t,message:i,relatedInformation:s,code:n}=e;let r=(t?.length||0)+2;n&&(r+="string"===typeof n?n.length:n.value.length);const o=(0,g.uz)(i);this._lines=o.length,this._longestLineLength=0;for(const h of o)this._longestLineLength=Math.max(h.length+r,this._longestLineLength);A.w_(this._messageBlock),this._messageBlock.setAttribute("aria-label",this.getAriaLabel(e)),this._editor.applyFontInfo(this._messageBlock);let a=this._messageBlock;for(const h of o)a=document.createElement("div"),a.innerText=h,""===h&&(a.style.height=this._messageBlock.style.lineHeight),this._messageBlock.appendChild(a);if(t||n){const e=document.createElement("span");if(e.classList.add("details"),a.appendChild(e),t){const i=document.createElement("span");i.innerText=t,i.classList.add("source"),e.appendChild(i)}if(n)if("string"===typeof n){const t=document.createElement("span");t.innerText=`(${n})`,t.classList.add("code"),e.appendChild(t)}else{this._codeLink=A.$("a.code-link"),this._codeLink.setAttribute("href",`${n.target.toString()}`),this._codeLink.onclick=e=>{this._openerService.open(n.target,{allowCommands:!0}),e.preventDefault(),e.stopPropagation()};A.BC(this._codeLink,A.$("span")).innerText=n.value,e.appendChild(this._codeLink)}}if(A.w_(this._relatedBlock),this._editor.applyFontInfo(this._relatedBlock),(0,h.EI)(s)){const e=this._relatedBlock.appendChild(document.createElement("div"));e.style.paddingTop=`${Math.floor(.66*this._editor.getOption(67))}px`,this._lines+=1;for(const t of s){const i=document.createElement("div"),s=document.createElement("a");s.classList.add("filename"),s.innerText=`${this._labelService.getUriBasenameLabel(t.resource)}(${t.startLineNumber}, ${t.startColumn}): `,s.title=this._labelService.getUriLabel(t.resource),this._relatedDiagnostics.set(s,t);const n=document.createElement("span");n.innerText=t.message,i.appendChild(s),i.appendChild(n),this._lines+=1,e.appendChild(i)}}const l=this._editor.getOption(50),c=Math.ceil(l.typicalFullwidthCharacterWidth*this._longestLineLength*.75),d=l.lineHeight*this._lines;this._scrollable.setScrollDimensions({scrollWidth:c,scrollHeight:d})}layout(e,t){this._scrollable.getDomNode().style.height=`${e}px`,this._scrollable.getDomNode().style.width=`${t}px`,this._scrollable.setScrollDimensions({width:t,height:e})}getHeightInLines(){return Math.min(17,this._lines)}getAriaLabel(e){let t="";switch(e.severity){case _.cj.Error:t=R.kg("Error","Error");break;case _.cj.Warning:t=R.kg("Warning","Warning");break;case _.cj.Info:t=R.kg("Info","Info");break;case _.cj.Hint:t=R.kg("Hint","Hint")}let i=R.kg("marker aria","{0} at {1}. ",t,e.startLineNumber+":"+e.startColumn);const s=this._editor.getModel();if(s&&e.startLineNumber<=s.getLineCount()&&e.startLineNumber>=1){i=`${s.getLineContent(e.startLineNumber)}, ${i}`}return i}}let K=class extends D.j6{static{B=this}static{this.TitleMenu=new T.D8("gotoErrorTitleMenu")}constructor(e,t,i,s,r,o,a){super(e,{showArrow:!0,showFrame:!0,isAccessible:!0,frameWidth:1},r),this._themeService=t,this._openerService=i,this._menuService=s,this._contextKeyService=o,this._labelService=a,this._callOnDispose=new n.Cm,this._onDidSelectRelatedInformation=new d.vl,this.onDidSelectRelatedInformation=this._onDidSelectRelatedInformation.event,this._severity=_.cj.Warning,this._backgroundColor=I.Q1.white,this._applyTheme(t.getColorTheme()),this._callOnDispose.add(t.onDidColorThemeChange(this._applyTheme.bind(this))),this.create()}_applyTheme(e){this._backgroundColor=e.getColor(ie);let t=Q,i=X;this._severity===_.cj.Warning?(t=Z,i=J):this._severity===_.cj.Info&&(t=ee,i=te);const s=e.getColor(t),n=e.getColor(i);this.style({arrowColor:s,frameColor:s,headerBackgroundColor:n,primaryHeadingColor:e.getColor(D._X),secondaryHeadingColor:e.getColor(D.e3)})}_applyStyles(){this._parentContainer&&(this._parentContainer.style.backgroundColor=this._backgroundColor?this._backgroundColor.toString():""),super._applyStyles()}dispose(){this._callOnDispose.dispose(),super.dispose()}_fillHead(e){super._fillHead(e),this._disposables.add(this._actionbarWidget.actionRunner.onWillRun((e=>this.editor.focus())));const t=[],i=this._menuService.getMenuActions(B.TitleMenu,this._contextKeyService);(0,M.Ot)(i,t),this._actionbarWidget.push(t,{label:!1,icon:!0,index:0})}_fillTitleIcon(e){this._icon=A.BC(e,A.$(""))}_fillBody(e){this._parentContainer=e,e.classList.add("marker-widget"),this._parentContainer.tabIndex=0,this._parentContainer.setAttribute("role","tooltip"),this._container=document.createElement("div"),e.appendChild(this._container),this._message=new j(this._container,this.editor,(e=>this._onDidSelectRelatedInformation.fire(e)),this._openerService,this._labelService),this._disposables.add(this._message)}show(){throw new Error("call showAtMarker")}showAtMarker(e,t,i){this._container.classList.remove("stale"),this._message.update(e),this._severity=e.severity,this._applyTheme(this._themeService.getColorTheme());const s=l.Q.lift(e),n=this.editor.getPosition(),r=n&&s.containsPosition(n)?n:s.getStartPosition();super.show(r,this.computeRequiredHeight());const o=this.editor.getModel();if(o){const e=i>1?R.kg("problems","{0} of {1} problems",t,i):R.kg("change","{0} of {1} problem",t,i);this.setTitle((0,O.P8)(o.uri),e)}this._icon.className=`codicon ${L.className(_.cj.toSeverity(this._severity))}`,this.editor.revealPositionNearTop(r,0),this.editor.focus()}updateMarker(e){this._container.classList.remove("stale"),this._message.update(e)}showStale(){this._container.classList.add("stale"),this._relayout()}_doLayoutBody(e,t){super._doLayoutBody(e,t),this._heightInPixel=e,this._message.layout(e,t),this._container.style.height=`${e}px`}_onWidth(e){this._message.layout(this._heightInPixel,e)}_relayout(){super._relayout(this.computeRequiredHeight())}computeRequiredHeight(){return 3+this._message.getHeightInLines()}};K=B=z([G(1,V.Gy),G(2,F.C),G(3,T.ez),G(4,f._Y),G(5,x.fN),G(6,P.L)],K);const Y=(0,W.yLr)(W.Rbi,W.AN$),q=(0,W.yLr)(W.Hng,W.Stt),$=(0,W.yLr)(W.pOz,W.IIb),Q=(0,W.x1A)("editorMarkerNavigationError.background",{dark:Y,light:Y,hcDark:W.b1q,hcLight:W.b1q},R.kg("editorMarkerNavigationError","Editor marker navigation widget error color.")),X=(0,W.x1A)("editorMarkerNavigationError.headerBackground",{dark:(0,W.JO0)(Q,.1),light:(0,W.JO0)(Q,.1),hcDark:null,hcLight:null},R.kg("editorMarkerNavigationErrorHeaderBackground","Editor marker navigation widget error heading background.")),Z=(0,W.x1A)("editorMarkerNavigationWarning.background",{dark:q,light:q,hcDark:W.b1q,hcLight:W.b1q},R.kg("editorMarkerNavigationWarning","Editor marker navigation widget warning color.")),J=(0,W.x1A)("editorMarkerNavigationWarning.headerBackground",{dark:(0,W.JO0)(Z,.1),light:(0,W.JO0)(Z,.1),hcDark:"#0C141F",hcLight:(0,W.JO0)(Z,.2)},R.kg("editorMarkerNavigationWarningBackground","Editor marker navigation widget warning heading background.")),ee=(0,W.x1A)("editorMarkerNavigationInfo.background",{dark:$,light:$,hcDark:W.b1q,hcLight:W.b1q},R.kg("editorMarkerNavigationInfo","Editor marker navigation widget info color.")),te=(0,W.x1A)("editorMarkerNavigationInfo.headerBackground",{dark:(0,W.JO0)(ee,.1),light:(0,W.JO0)(ee,.1),hcDark:null,hcLight:null},R.kg("editorMarkerNavigationInfoHeaderBackground","Editor marker navigation widget info heading background.")),ie=(0,W.x1A)("editorMarkerNavigation.background",W.YtV,R.kg("editorMarkerNavigationBackground","Editor marker navigation widget background."));var se,ne=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},re=function(e,t){return function(i,s){t(i,s,e)}};let oe=class{static{se=this}static{this.ID="editor.contrib.markerController"}static get(e){return e.getContribution(se.ID)}constructor(e,t,i,s,r){this._markerNavigationService=t,this._contextKeyService=i,this._editorService=s,this._instantiationService=r,this._sessionDispoables=new n.Cm,this._editor=e,this._widgetVisible=he.bindTo(this._contextKeyService)}dispose(){this._cleanUp(),this._sessionDispoables.dispose()}_cleanUp(){this._widgetVisible.reset(),this._sessionDispoables.clear(),this._widget=void 0,this._model=void 0}_getOrCreateModel(e){if(this._model&&this._model.matches(e))return this._model;let t=!1;return this._model&&(t=!0,this._cleanUp()),this._model=this._markerNavigationService.getMarkerList(e),t&&this._model.move(!0,this._editor.getModel(),this._editor.getPosition()),this._widget=this._instantiationService.createInstance(K,this._editor),this._widget.onDidClose((()=>this.close()),this,this._sessionDispoables),this._widgetVisible.set(!0),this._sessionDispoables.add(this._model),this._sessionDispoables.add(this._widget),this._sessionDispoables.add(this._editor.onDidChangeCursorPosition((e=>{this._model?.selected&&l.Q.containsPosition(this._model?.selected.marker,e.position)||this._model?.resetIndex()}))),this._sessionDispoables.add(this._model.onDidChange((()=>{if(!this._widget||!this._widget.position||!this._model)return;const e=this._model.find(this._editor.getModel().uri,this._widget.position);e?this._widget.updateMarker(e.marker):this._widget.showStale()}))),this._sessionDispoables.add(this._widget.onDidSelectRelatedInformation((e=>{this._editorService.openCodeEditor({resource:e.resource,options:{pinned:!0,revealIfOpened:!0,selection:l.Q.lift(e).collapseToStart()}},this._editor),this.close(!1)}))),this._sessionDispoables.add(this._editor.onDidChangeModel((()=>this._cleanUp()))),this._model}close(e=!0){this._cleanUp(),e&&this._editor.focus()}showAtMarker(e){if(this._editor.hasModel()){const t=this._getOrCreateModel(this._editor.getModel().uri);t.resetIndex(),t.move(!0,this._editor.getModel(),new a.y(e.startLineNumber,e.startColumn)),t.selected&&this._widget.showAtMarker(t.selected.marker,t.selected.index,t.selected.total)}}async nagivate(e,t){if(this._editor.hasModel()){const i=this._getOrCreateModel(t?void 0:this._editor.getModel().uri);if(i.move(e,this._editor.getModel(),this._editor.getPosition()),!i.selected)return;if(i.selected.marker.resource.toString()!==this._editor.getModel().uri.toString()){this._cleanUp();const s=await this._editorService.openCodeEditor({resource:i.selected.marker.resource,options:{pinned:!1,revealIfOpened:!0,selectionRevealType:2,selection:i.selected.marker}},this._editor);s&&(se.get(s)?.close(),se.get(s)?.nagivate(e,t))}else this._widget.showAtMarker(i.selected.marker,i.selected.index,i.selected.total)}}};oe=se=ne([re(1,y),re(2,x.fN),re(3,o.T),re(4,f._Y)],oe);class ae extends r.ks{constructor(e,t,i){super(i),this._next=e,this._multiFile=t}async run(e,t){t.hasModel()&&oe.get(t)?.nagivate(this._next,this._multiFile)}}class le extends ae{static{this.ID="editor.action.marker.next"}static{this.LABEL=R.kg("markerAction.next.label","Go to Next Problem (Error, Warning, Info)")}constructor(){super(!0,!1,{id:le.ID,label:le.LABEL,alias:"Go to Next Problem (Error, Warning, Info)",precondition:void 0,kbOpts:{kbExpr:c.R.focus,primary:578,weight:100},menuOpts:{menuId:K.TitleMenu,title:le.LABEL,icon:(0,k.pU)("marker-navigation-next",s.W.arrowDown,R.kg("nextMarkerIcon","Icon for goto next marker.")),group:"navigation",order:1}})}}class ce extends ae{static{this.ID="editor.action.marker.prev"}static{this.LABEL=R.kg("markerAction.previous.label","Go to Previous Problem (Error, Warning, Info)")}constructor(){super(!1,!1,{id:ce.ID,label:ce.LABEL,alias:"Go to Previous Problem (Error, Warning, Info)",precondition:void 0,kbOpts:{kbExpr:c.R.focus,primary:1602,weight:100},menuOpts:{menuId:K.TitleMenu,title:ce.LABEL,icon:(0,k.pU)("marker-navigation-previous",s.W.arrowUp,R.kg("previousMarkerIcon","Icon for goto previous marker.")),group:"navigation",order:2}})}}(0,r.HW)(oe.ID,oe,4),(0,r.Fl)(le),(0,r.Fl)(ce),(0,r.Fl)(class extends ae{constructor(){super(!0,!0,{id:"editor.action.marker.nextInFiles",label:R.kg("markerAction.nextInFiles.label","Go to Next Problem in Files (Error, Warning, Info)"),alias:"Go to Next Problem in Files (Error, Warning, Info)",precondition:void 0,kbOpts:{kbExpr:c.R.focus,primary:66,weight:100},menuOpts:{menuId:T.D8.MenubarGoMenu,title:R.kg({key:"miGotoNextProblem",comment:["&& denotes a mnemonic"]},"Next &&Problem"),group:"6_problem_nav",order:1}})}}),(0,r.Fl)(class extends ae{constructor(){super(!1,!0,{id:"editor.action.marker.prevInFiles",label:R.kg("markerAction.previousInFiles.label","Go to Previous Problem in Files (Error, Warning, Info)"),alias:"Go to Previous Problem in Files (Error, Warning, Info)",precondition:void 0,kbOpts:{kbExpr:c.R.focus,primary:1090,weight:100},menuOpts:{menuId:T.D8.MenubarGoMenu,title:R.kg({key:"miGotoPreviousProblem",comment:["&& denotes a mnemonic"]},"Previous &&Problem"),group:"6_problem_nav",order:2}})}});const he=new x.N1("markersNavigationVisible",!1),de=r.DX.bindToContribution(oe.get);(0,r.E_)(new de({id:"closeMarkersNavigation",precondition:he,handler:e=>e.close(),kbOpts:{weight:150,kbExpr:c.R.focus,primary:9,secondary:[1033]}}))},99312:(e,t,i)=>{"use strict";i.d(t,{mR:()=>K,bn:()=>j,QS:()=>G});var s=i(11007),n=i(90766),r=i(24939),o=i(631),a=i(79400),l=i(50868),c=i(34326),h=i(31450),d=i(80301),u=i(29163),g=i(83069),p=i(36677),m=i(60002),f=i(62083),_=i(23646),v=i(79614),C=i(41234),b=i(5662),E=i(89403),S=i(78209),y=i(32848),w=i(14718),L=i(63591),R=i(98031),T=i(59261),x=i(58591),k=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},A=function(e,t){return function(i,s){t(i,s,e)}};const N=new y.N1("hasSymbols",!1,(0,S.kg)("hasSymbols","Whether there are symbol locations that can be navigated via keyboard-only.")),I=(0,L.u1)("ISymbolNavigationService");let O=class{constructor(e,t,i,s){this._editorService=t,this._notificationService=i,this._keybindingService=s,this._currentModel=void 0,this._currentIdx=-1,this._ignoreEditorChange=!1,this._ctxHasSymbols=N.bindTo(e)}reset(){this._ctxHasSymbols.reset(),this._currentState?.dispose(),this._currentMessage?.dispose(),this._currentModel=void 0,this._currentIdx=-1}put(e){const t=e.parent.parent;if(t.references.length<=1)return void this.reset();this._currentModel=t,this._currentIdx=t.references.indexOf(e),this._ctxHasSymbols.set(!0),this._showMessage();const i=new D(this._editorService),s=i.onDidChange((e=>{if(this._ignoreEditorChange)return;const i=this._editorService.getActiveCodeEditor();if(!i)return;const s=i.getModel(),n=i.getPosition();if(!s||!n)return;let r=!1,o=!1;for(const a of t.references)if((0,E.n4)(a.uri,s.uri))r=!0,o=o||p.Q.containsPosition(a.range,n);else if(r)break;r&&o||this.reset()}));this._currentState=(0,b.qE)(i,s)}revealNext(e){if(!this._currentModel)return Promise.resolve();this._currentIdx+=1,this._currentIdx%=this._currentModel.references.length;const t=this._currentModel.references[this._currentIdx];return this._showMessage(),this._ignoreEditorChange=!0,this._editorService.openCodeEditor({resource:t.uri,options:{selection:p.Q.collapseToStart(t.range),selectionRevealType:3}},e).finally((()=>{this._ignoreEditorChange=!1}))}_showMessage(){this._currentMessage?.dispose();const e=this._keybindingService.lookupKeybinding("editor.gotoNextSymbolFromResult"),t=e?(0,S.kg)("location.kb","Symbol {0} of {1}, {2} for next",this._currentIdx+1,this._currentModel.references.length,e.getLabel()):(0,S.kg)("location","Symbol {0} of {1}",this._currentIdx+1,this._currentModel.references.length);this._currentMessage=this._notificationService.status(t)}};O=k([A(0,y.fN),A(1,d.T),A(2,x.Ot),A(3,R.b)],O),(0,w.v)(I,O,1),(0,h.E_)(new class extends h.DX{constructor(){super({id:"editor.gotoNextSymbolFromResult",precondition:N,kbOpts:{weight:100,primary:70}})}runEditorCommand(e,t){return e.get(I).revealNext(t)}}),T.f.registerCommandAndKeybindingRule({id:"editor.gotoNextSymbolFromResult.cancel",weight:100,when:N,primary:9,handler(e){e.get(I).reset()}});let D=class{constructor(e){this._listener=new Map,this._disposables=new b.Cm,this._onDidChange=new C.vl,this.onDidChange=this._onDidChange.event,this._disposables.add(e.onCodeEditorRemove(this._onDidRemoveEditor,this)),this._disposables.add(e.onCodeEditorAdd(this._onDidAddEditor,this)),e.listCodeEditors().forEach(this._onDidAddEditor,this)}dispose(){this._disposables.dispose(),this._onDidChange.dispose(),(0,b.AS)(this._listener.values())}_onDidAddEditor(e){this._listener.set(e,(0,b.qE)(e.onDidChangeCursorPosition((t=>this._onDidChange.fire({editor:e}))),e.onDidChangeModelContent((t=>this._onDidChange.fire({editor:e})))))}_onDidRemoveEditor(e){this._listener.get(e)?.dispose(),this._listener.delete(e)}};D=k([A(0,d.T)],D);var M=i(99645),P=i(84226),F=i(27195),U=i(50091),H=i(73823),B=i(80538),W=i(56942),V=i(42522),z=i(28290);F.ZG.appendMenuItem(F.D8.EditorContext,{submenu:F.D8.EditorContextPeek,title:S.kg("peek.submenu","Peek"),group:"navigation",order:100});class G{static is(e){return!(!e||"object"!==typeof e)&&(e instanceof G||!(!g.y.isIPosition(e.position)||!e.model))}constructor(e,t){this.model=e,this.position=t}}class j extends h.qO{static{this._allSymbolNavigationCommands=new Map}static{this._activeAlternativeCommands=new Set}static all(){return j._allSymbolNavigationCommands.values()}static _patchConfig(e){const t={...e,f1:!0};if(t.menu)for(const i of V.f.wrap(t.menu))i.id!==F.D8.EditorContext&&i.id!==F.D8.EditorContextPeek||(i.when=y.M$.and(e.precondition,i.when));return t}constructor(e,t){super(j._patchConfig(t)),this.configuration=e,j._allSymbolNavigationCommands.set(t.id,this)}runEditorCommand(e,t,i,r){if(!t.hasModel())return Promise.resolve(void 0);const o=e.get(x.Ot),a=e.get(d.T),c=e.get(H.N8),h=e.get(I),u=e.get(W.ILanguageFeaturesService),g=e.get(L._Y),p=t.getModel(),m=t.getPosition(),f=G.is(i)?i:new G(p,m),_=new l.gI(t,5),v=(0,n.PK)(this._getLocationModel(u,f.model,f.position,_.token),_.token).then((async e=>{if(!e||_.token.isCancellationRequested)return;let n;if((0,s.xE)(e.ariaMessage),e.referenceAt(p.uri,m)){const e=this._getAlternativeCommand(t);!j._activeAlternativeCommands.has(e)&&j._allSymbolNavigationCommands.has(e)&&(n=j._allSymbolNavigationCommands.get(e))}const o=e.references.length;if(0===o){if(!this.configuration.muteMessage){const e=p.getWordAtPosition(m);M.k.get(t)?.showMessage(this._getNoResultFoundMessage(e),m)}}else{if(1!==o||!n)return this._onResult(a,h,t,e,r);j._activeAlternativeCommands.add(this.desc.id),g.invokeFunction((e=>n.runEditorCommand(e,t,i,r).finally((()=>{j._activeAlternativeCommands.delete(this.desc.id)}))))}}),(e=>{o.error(e)})).finally((()=>{_.dispose()}));return c.showWhile(v,250),v}async _onResult(e,t,i,s,n){const r=this._getGoToPreference(i);if(i instanceof u.t||!(this.configuration.openInPeek||"peek"===r&&s.references.length>1)){const o=s.firstReference(),a=s.references.length>1&&"gotoAndPeek"===r,l=await this._openReference(i,e,o,this.configuration.openToSide,!a);a&&l?this._openInPeek(l,s,n):s.dispose(),"goto"===r&&t.put(o)}else this._openInPeek(i,s,n)}async _openReference(e,t,i,s,n){let r;if((0,f.Iu)(i)&&(r=i.targetSelectionRange),r||(r=i.range),!r)return;const o=await t.openCodeEditor({resource:i.uri,options:{selection:p.Q.collapseToStart(r),selectionRevealType:3,selectionSource:"code.jump"}},e,s);if(o){if(n){const e=o.getModel(),t=o.createDecorationsCollection([{range:r,options:{description:"symbol-navigate-action-highlight",className:"symbolHighlight"}}]);setTimeout((()=>{o.getModel()===e&&t.clear()}),350)}return o}}_openInPeek(e,t,i){const s=_.X.get(e);s&&e.hasModel()?s.toggleWidget(i??e.getSelection(),(0,n.SS)((e=>Promise.resolve(t))),this.configuration.openInPeek):t.dispose()}}class K extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.hE)(e.definitionProvider,t,i,!1,s),S.kg("def.title","Definitions"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("noResultWord","No definition found for '{0}'",e.word):S.kg("generic.noResults","No definition found")}_getAlternativeCommand(e){return e.getOption(58).alternativeDefinitionCommand}_getGoToPreference(e){return e.getOption(58).multipleDefinitions}}(0,F.ug)(class e extends K{static{this.id="editor.action.revealDefinition"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.id,title:{...S.aS("actions.goToDecl.label","Go to Definition"),mnemonicTitle:S.kg({key:"miGotoDefinition",comment:["&& denotes a mnemonic"]},"Go to &&Definition")},precondition:m.R.hasDefinitionProvider,keybinding:[{when:m.R.editorTextFocus,primary:70,weight:100},{when:y.M$.and(m.R.editorTextFocus,z.W0),primary:2118,weight:100}],menu:[{id:F.D8.EditorContext,group:"navigation",order:1.1},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:2}]}),U.w.registerCommandAlias("editor.action.goToDeclaration",e.id)}}),(0,F.ug)(class e extends K{static{this.id="editor.action.revealDefinitionAside"}constructor(){super({openToSide:!0,openInPeek:!1,muteMessage:!1},{id:e.id,title:S.aS("actions.goToDeclToSide.label","Open Definition to the Side"),precondition:y.M$.and(m.R.hasDefinitionProvider,m.R.isInEmbeddedEditor.toNegated()),keybinding:[{when:m.R.editorTextFocus,primary:(0,r.m5)(2089,70),weight:100},{when:y.M$.and(m.R.editorTextFocus,z.W0),primary:(0,r.m5)(2089,2118),weight:100}]}),U.w.registerCommandAlias("editor.action.openDeclarationToTheSide",e.id)}}),(0,F.ug)(class e extends K{static{this.id="editor.action.peekDefinition"}constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:e.id,title:S.aS("actions.previewDecl.label","Peek Definition"),precondition:y.M$.and(m.R.hasDefinitionProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),keybinding:{when:m.R.editorTextFocus,primary:582,linux:{primary:3140},weight:100},menu:{id:F.D8.EditorContextPeek,group:"peek",order:2}}),U.w.registerCommandAlias("editor.action.previewDeclaration",e.id)}});class Y extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.sv)(e.declarationProvider,t,i,!1,s),S.kg("decl.title","Declarations"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("decl.noResultWord","No declaration found for '{0}'",e.word):S.kg("decl.generic.noResults","No declaration found")}_getAlternativeCommand(e){return e.getOption(58).alternativeDeclarationCommand}_getGoToPreference(e){return e.getOption(58).multipleDeclarations}}(0,F.ug)(class e extends Y{static{this.id="editor.action.revealDeclaration"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.id,title:{...S.aS("actions.goToDeclaration.label","Go to Declaration"),mnemonicTitle:S.kg({key:"miGotoDeclaration",comment:["&& denotes a mnemonic"]},"Go to &&Declaration")},precondition:y.M$.and(m.R.hasDeclarationProvider,m.R.isInEmbeddedEditor.toNegated()),menu:[{id:F.D8.EditorContext,group:"navigation",order:1.3},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:3}]})}_getNoResultFoundMessage(e){return e&&e.word?S.kg("decl.noResultWord","No declaration found for '{0}'",e.word):S.kg("decl.generic.noResults","No declaration found")}}),(0,F.ug)(class extends Y{constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:"editor.action.peekDeclaration",title:S.aS("actions.peekDecl.label","Peek Declaration"),precondition:y.M$.and(m.R.hasDeclarationProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),menu:{id:F.D8.EditorContextPeek,group:"peek",order:3}})}});class q extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.f9)(e.typeDefinitionProvider,t,i,!1,s),S.kg("typedef.title","Type Definitions"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("goToTypeDefinition.noResultWord","No type definition found for '{0}'",e.word):S.kg("goToTypeDefinition.generic.noResults","No type definition found")}_getAlternativeCommand(e){return e.getOption(58).alternativeTypeDefinitionCommand}_getGoToPreference(e){return e.getOption(58).multipleTypeDefinitions}}(0,F.ug)(class e extends q{static{this.ID="editor.action.goToTypeDefinition"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.ID,title:{...S.aS("actions.goToTypeDefinition.label","Go to Type Definition"),mnemonicTitle:S.kg({key:"miGotoTypeDefinition",comment:["&& denotes a mnemonic"]},"Go to &&Type Definition")},precondition:m.R.hasTypeDefinitionProvider,keybinding:{when:m.R.editorTextFocus,primary:0,weight:100},menu:[{id:F.D8.EditorContext,group:"navigation",order:1.4},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:3}]})}}),(0,F.ug)(class e extends q{static{this.ID="editor.action.peekTypeDefinition"}constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:e.ID,title:S.aS("actions.peekTypeDefinition.label","Peek Type Definition"),precondition:y.M$.and(m.R.hasTypeDefinitionProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),menu:{id:F.D8.EditorContextPeek,group:"peek",order:4}})}});class $ extends j{async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.eS)(e.implementationProvider,t,i,!1,s),S.kg("impl.title","Implementations"))}_getNoResultFoundMessage(e){return e&&e.word?S.kg("goToImplementation.noResultWord","No implementation found for '{0}'",e.word):S.kg("goToImplementation.generic.noResults","No implementation found")}_getAlternativeCommand(e){return e.getOption(58).alternativeImplementationCommand}_getGoToPreference(e){return e.getOption(58).multipleImplementations}}(0,F.ug)(class e extends ${static{this.ID="editor.action.goToImplementation"}constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:e.ID,title:{...S.aS("actions.goToImplementation.label","Go to Implementations"),mnemonicTitle:S.kg({key:"miGotoImplementation",comment:["&& denotes a mnemonic"]},"Go to &&Implementations")},precondition:m.R.hasImplementationProvider,keybinding:{when:m.R.editorTextFocus,primary:2118,weight:100},menu:[{id:F.D8.EditorContext,group:"navigation",order:1.45},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:4}]})}}),(0,F.ug)(class e extends ${static{this.ID="editor.action.peekImplementation"}constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:e.ID,title:S.aS("actions.peekImplementation.label","Peek Implementations"),precondition:y.M$.and(m.R.hasImplementationProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),keybinding:{when:m.R.editorTextFocus,primary:3142,weight:100},menu:{id:F.D8.EditorContextPeek,group:"peek",order:5}})}});class Q extends j{_getNoResultFoundMessage(e){return e?S.kg("references.no","No references found for '{0}'",e.word):S.kg("references.noGeneric","No references found")}_getAlternativeCommand(e){return e.getOption(58).alternativeReferenceCommand}_getGoToPreference(e){return e.getOption(58).multipleReferences}}(0,F.ug)(class extends Q{constructor(){super({openToSide:!1,openInPeek:!1,muteMessage:!1},{id:"editor.action.goToReferences",title:{...S.aS("goToReferences.label","Go to References"),mnemonicTitle:S.kg({key:"miGotoReference",comment:["&& denotes a mnemonic"]},"Go to &&References")},precondition:y.M$.and(m.R.hasReferenceProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),keybinding:{when:m.R.editorTextFocus,primary:1094,weight:100},menu:[{id:F.D8.EditorContext,group:"navigation",order:1.45},{id:F.D8.MenubarGoMenu,precondition:null,group:"4_symbol_nav",order:5}]})}async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.NN)(e.referenceProvider,t,i,!0,!1,s),S.kg("ref.title","References"))}}),(0,F.ug)(class extends Q{constructor(){super({openToSide:!1,openInPeek:!0,muteMessage:!1},{id:"editor.action.referenceSearch.trigger",title:S.aS("references.action.label","Peek References"),precondition:y.M$.and(m.R.hasReferenceProvider,P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated()),menu:{id:F.D8.EditorContextPeek,group:"peek",order:6}})}async _getLocationModel(e,t,i,s){return new v.y4(await(0,B.NN)(e.referenceProvider,t,i,!1,!1,s),S.kg("ref.title","References"))}});class X extends j{constructor(e,t,i){super(e,{id:"editor.action.goToLocation",title:S.aS("label.generic","Go to Any Symbol"),precondition:y.M$.and(P.x2.notInPeekEditor,m.R.isInEmbeddedEditor.toNegated())}),this._references=t,this._gotoMultipleBehaviour=i}async _getLocationModel(e,t,i,s){return new v.y4(this._references,S.kg("generic.title","Locations"))}_getNoResultFoundMessage(e){return e&&S.kg("generic.noResult","No results for '{0}'",e.word)||""}_getGoToPreference(e){return this._gotoMultipleBehaviour??e.getOption(58).multipleReferences}_getAlternativeCommand(){return""}}U.w.registerCommand({id:"editor.action.goToLocations",metadata:{description:"Go to locations from a position in a file",args:[{name:"uri",description:"The text document in which to start",constraint:a.r},{name:"position",description:"The position at which to start",constraint:g.y.isIPosition},{name:"locations",description:"An array of locations.",constraint:Array},{name:"multiple",description:"Define what to do when having multiple results, either `peek`, `gotoAndPeek`, or `goto`"},{name:"noResultsMessage",description:"Human readable message that shows when locations is empty."}]},handler:async(e,t,i,s,n,r,l)=>{(0,o.j)(a.r.isUri(t)),(0,o.j)(g.y.isIPosition(i)),(0,o.j)(Array.isArray(s)),(0,o.j)("undefined"===typeof n||"string"===typeof n),(0,o.j)("undefined"===typeof l||"boolean"===typeof l);const h=e.get(d.T),u=await h.openCodeEditor({resource:t},h.getFocusedCodeEditor());if((0,c.z9)(u))return u.setPosition(i),u.revealPositionInCenterIfOutsideViewport(i,0),u.invokeWithinContext((e=>{const t=new class extends X{_getNoResultFoundMessage(e){return r||super._getNoResultFoundMessage(e)}}({muteMessage:!Boolean(r),openInPeek:Boolean(l),openToSide:!1},s,n);e.get(L._Y).invokeFunction(t.run.bind(t),u)}))}}),U.w.registerCommand({id:"editor.action.peekLocations",metadata:{description:"Peek locations from a position in a file",args:[{name:"uri",description:"The text document in which to start",constraint:a.r},{name:"position",description:"The position at which to start",constraint:g.y.isIPosition},{name:"locations",description:"An array of locations.",constraint:Array},{name:"multiple",description:"Define what to do when having multiple results, either `peek`, `gotoAndPeek`, or `goto`"}]},handler:async(e,t,i,s,n)=>{e.get(U.d).executeCommand("editor.action.goToLocations",t,i,s,n,void 0,!0)}}),U.w.registerCommand({id:"editor.action.findReferences",handler:(e,t,i)=>{(0,o.j)(a.r.isUri(t)),(0,o.j)(g.y.isIPosition(i));const s=e.get(W.ILanguageFeaturesService),r=e.get(d.T);return r.openCodeEditor({resource:t},r.getFocusedCodeEditor()).then((e=>{if(!(0,c.z9)(e)||!e.hasModel())return;const t=_.X.get(e);if(!t)return;const r=(0,n.SS)((t=>(0,B.NN)(s.referenceProvider,e.getModel(),g.y.lift(i),!1,!1,t).then((e=>new v.y4(e,S.kg("ref.title","References")))))),o=new p.Q(i.lineNumber,i.column,i.lineNumber,i.column);return Promise.resolve(t.toggleWidget(o,r,!1))}))}}),U.w.registerCommandAlias("editor.action.showReferences","editor.action.peekLocations")},80538:(e,t,i)=>{"use strict";i.d(t,{NN:()=>f,eS:()=>p,f9:()=>m,hE:()=>u,sv:()=>g});var s=i(25890),n=i(18447),r=i(64383),o=i(36456),a=i(31450),l=i(56942),c=i(79614);function h(e,t){return t.uri.scheme===e.uri.scheme||!(0,o.fV)(t.uri,o.ny.walkThroughSnippet,o.ny.vscodeChatCodeBlock,o.ny.vscodeChatCodeCompareBlock)}async function d(e,t,i,n,o){const a=i.ordered(e,n).map((i=>Promise.resolve(o(i,e,t)).then(void 0,(e=>{(0,r.M_)(e)})))),l=await Promise.all(a);return(0,s.Yc)(l.flat()).filter((t=>h(e,t)))}function u(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideDefinition(t,i,n)))}function g(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideDeclaration(t,i,n)))}function p(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideImplementation(t,i,n)))}function m(e,t,i,s,n){return d(t,i,e,s,((e,t,i)=>e.provideTypeDefinition(t,i,n)))}function f(e,t,i,s,n,r){return d(t,i,e,n,(async(e,t,i)=>{const n=(await e.provideReferences(t,i,{includeDeclaration:!0},r))?.filter((e=>h(t,e)));if(!s||!n||2!==n.length)return n;const o=(await e.provideReferences(t,i,{includeDeclaration:!1},r))?.filter((e=>h(t,e)));return o&&1===o.length?o:n}))}async function _(e){const t=await e(),i=new c.y4(t,""),s=i.references.map((e=>e.link));return i.dispose(),s}(0,a.ke)("_executeDefinitionProvider",((e,t,i)=>{const s=u(e.get(l.ILanguageFeaturesService).definitionProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeDefinitionProvider_recursive",((e,t,i)=>{const s=u(e.get(l.ILanguageFeaturesService).definitionProvider,t,i,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeTypeDefinitionProvider",((e,t,i)=>{const s=m(e.get(l.ILanguageFeaturesService).typeDefinitionProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeTypeDefinitionProvider_recursive",((e,t,i)=>{const s=m(e.get(l.ILanguageFeaturesService).typeDefinitionProvider,t,i,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeDeclarationProvider",((e,t,i)=>{const s=g(e.get(l.ILanguageFeaturesService).declarationProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeDeclarationProvider_recursive",((e,t,i)=>{const s=g(e.get(l.ILanguageFeaturesService).declarationProvider,t,i,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeReferenceProvider",((e,t,i)=>{const s=f(e.get(l.ILanguageFeaturesService).referenceProvider,t,i,!1,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeReferenceProvider_recursive",((e,t,i)=>{const s=f(e.get(l.ILanguageFeaturesService).referenceProvider,t,i,!1,!0,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeImplementationProvider",((e,t,i)=>{const s=p(e.get(l.ILanguageFeaturesService).implementationProvider,t,i,!1,n.XO.None);return _((()=>s))})),(0,a.ke)("_executeImplementationProvider_recursive",((e,t,i)=>{const s=p(e.get(l.ILanguageFeaturesService).implementationProvider,t,i,!0,n.XO.None);return _((()=>s))}))},37927:(e,t,i)=>{"use strict";i.d(t,{gi:()=>d});var s=i(41234),n=i(5662),r=i(98067);function o(e,t){return!!e[t]}class a{constructor(e,t){this.target=e.target,this.isLeftClick=e.event.leftButton,this.isMiddleClick=e.event.middleButton,this.isRightClick=e.event.rightButton,this.hasTriggerModifier=o(e.event,t.triggerModifier),this.hasSideBySideModifier=o(e.event,t.triggerSideBySideModifier),this.isNoneOrSingleMouseDown=e.event.detail<=1}}class l{constructor(e,t){this.keyCodeIsTriggerKey=e.keyCode===t.triggerKey,this.keyCodeIsSideBySideKey=e.keyCode===t.triggerSideBySideKey,this.hasTriggerModifier=o(e,t.triggerModifier)}}class c{constructor(e,t,i,s){this.triggerKey=e,this.triggerModifier=t,this.triggerSideBySideKey=i,this.triggerSideBySideModifier=s}equals(e){return this.triggerKey===e.triggerKey&&this.triggerModifier===e.triggerModifier&&this.triggerSideBySideKey===e.triggerSideBySideKey&&this.triggerSideBySideModifier===e.triggerSideBySideModifier}}function h(e){return"altKey"===e?r.zx?new c(57,"metaKey",6,"altKey"):new c(5,"ctrlKey",6,"altKey"):r.zx?new c(6,"altKey",57,"metaKey"):new c(6,"altKey",5,"ctrlKey")}class d extends n.jG{constructor(e,t){super(),this._onMouseMoveOrRelevantKeyDown=this._register(new s.vl),this.onMouseMoveOrRelevantKeyDown=this._onMouseMoveOrRelevantKeyDown.event,this._onExecute=this._register(new s.vl),this.onExecute=this._onExecute.event,this._onCancel=this._register(new s.vl),this.onCancel=this._onCancel.event,this._editor=e,this._extractLineNumberFromMouseEvent=t?.extractLineNumberFromMouseEvent??(e=>e.target.position?e.target.position.lineNumber:0),this._opts=h(this._editor.getOption(78)),this._lastMouseMoveEvent=null,this._hasTriggerKeyOnMouseDown=!1,this._lineNumberOnMouseDown=0,this._register(this._editor.onDidChangeConfiguration((e=>{if(e.hasChanged(78)){const e=h(this._editor.getOption(78));if(this._opts.equals(e))return;this._opts=e,this._lastMouseMoveEvent=null,this._hasTriggerKeyOnMouseDown=!1,this._lineNumberOnMouseDown=0,this._onCancel.fire()}}))),this._register(this._editor.onMouseMove((e=>this._onEditorMouseMove(new a(e,this._opts))))),this._register(this._editor.onMouseDown((e=>this._onEditorMouseDown(new a(e,this._opts))))),this._register(this._editor.onMouseUp((e=>this._onEditorMouseUp(new a(e,this._opts))))),this._register(this._editor.onKeyDown((e=>this._onEditorKeyDown(new l(e,this._opts))))),this._register(this._editor.onKeyUp((e=>this._onEditorKeyUp(new l(e,this._opts))))),this._register(this._editor.onMouseDrag((()=>this._resetHandler()))),this._register(this._editor.onDidChangeCursorSelection((e=>this._onDidChangeCursorSelection(e)))),this._register(this._editor.onDidChangeModel((e=>this._resetHandler()))),this._register(this._editor.onDidChangeModelContent((()=>this._resetHandler()))),this._register(this._editor.onDidScrollChange((e=>{(e.scrollTopChanged||e.scrollLeftChanged)&&this._resetHandler()})))}_onDidChangeCursorSelection(e){e.selection&&e.selection.startColumn!==e.selection.endColumn&&this._resetHandler()}_onEditorMouseMove(e){this._lastMouseMoveEvent=e,this._onMouseMoveOrRelevantKeyDown.fire([e,null])}_onEditorMouseDown(e){this._hasTriggerKeyOnMouseDown=e.hasTriggerModifier,this._lineNumberOnMouseDown=this._extractLineNumberFromMouseEvent(e)}_onEditorMouseUp(e){const t=this._extractLineNumberFromMouseEvent(e);this._hasTriggerKeyOnMouseDown&&this._lineNumberOnMouseDown&&this._lineNumberOnMouseDown===t&&this._onExecute.fire(e)}_onEditorKeyDown(e){this._lastMouseMoveEvent&&(e.keyCodeIsTriggerKey||e.keyCodeIsSideBySideKey&&e.hasTriggerModifier)?this._onMouseMoveOrRelevantKeyDown.fire([this._lastMouseMoveEvent,e]):e.hasTriggerModifier&&this._onCancel.fire()}_onEditorKeyUp(e){e.keyCodeIsTriggerKey&&this._onCancel.fire()}_resetHandler(){this._lastMouseMoveEvent=null,this._hasTriggerKeyOnMouseDown=!1,this._onCancel.fire()}}},62427:(e,t,i)=>{"use strict";i.d(t,{k:()=>y});var s,n=i(90766),r=i(64383),o=i(16980),a=i(5662),l=i(50868),c=i(31450),h=i(36677),d=i(10154),u=i(18938),g=i(37927),p=i(84226),m=i(78209),f=i(32848),_=i(99312),v=i(80538),C=i(56942),b=i(87289),E=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},S=function(e,t){return function(i,s){t(i,s,e)}};let y=class{static{s=this}static{this.ID="editor.contrib.gotodefinitionatposition"}static{this.MAX_SOURCE_PREVIEW_LINES=8}constructor(e,t,i,s){this.textModelResolverService=t,this.languageService=i,this.languageFeaturesService=s,this.toUnhook=new a.Cm,this.toUnhookForKeyboard=new a.Cm,this.currentWordAtPosition=null,this.previousPromise=null,this.editor=e,this.linkDecorations=this.editor.createDecorationsCollection();const n=new g.gi(e);this.toUnhook.add(n),this.toUnhook.add(n.onMouseMoveOrRelevantKeyDown((([e,t])=>{this.startFindDefinitionFromMouse(e,t??void 0)}))),this.toUnhook.add(n.onExecute((e=>{this.isEnabled(e)&&this.gotoDefinition(e.target.position,e.hasSideBySideModifier).catch((e=>{(0,r.dz)(e)})).finally((()=>{this.removeLinkDecorations()}))}))),this.toUnhook.add(n.onCancel((()=>{this.removeLinkDecorations(),this.currentWordAtPosition=null})))}static get(e){return e.getContribution(s.ID)}async startFindDefinitionFromCursor(e){await this.startFindDefinition(e),this.toUnhookForKeyboard.add(this.editor.onDidChangeCursorPosition((()=>{this.currentWordAtPosition=null,this.removeLinkDecorations(),this.toUnhookForKeyboard.clear()}))),this.toUnhookForKeyboard.add(this.editor.onKeyDown((e=>{e&&(this.currentWordAtPosition=null,this.removeLinkDecorations(),this.toUnhookForKeyboard.clear())})))}startFindDefinitionFromMouse(e,t){if(9===e.target.type&&this.linkDecorations.length>0)return;if(!this.editor.hasModel()||!this.isEnabled(e,t))return this.currentWordAtPosition=null,void this.removeLinkDecorations();const i=e.target.position;this.startFindDefinition(i)}async startFindDefinition(e){this.toUnhookForKeyboard.clear();const t=e?this.editor.getModel()?.getWordAtPosition(e):null;if(!t)return this.currentWordAtPosition=null,void this.removeLinkDecorations();if(this.currentWordAtPosition&&this.currentWordAtPosition.startColumn===t.startColumn&&this.currentWordAtPosition.endColumn===t.endColumn&&this.currentWordAtPosition.word===t.word)return;this.currentWordAtPosition=t;const i=new l.$t(this.editor,15);let s;this.previousPromise&&(this.previousPromise.cancel(),this.previousPromise=null),this.previousPromise=(0,n.SS)((t=>this.findDefinition(e,t)));try{s=await this.previousPromise}catch(c){return void(0,r.dz)(c)}if(!s||!s.length||!i.validate(this.editor))return void this.removeLinkDecorations();const a=s[0].originSelectionRange?h.Q.lift(s[0].originSelectionRange):new h.Q(e.lineNumber,t.startColumn,e.lineNumber,t.endColumn);if(s.length>1){let e=a;for(const{originSelectionRange:t}of s)t&&(e=h.Q.plusRange(e,t));this.addDecoration(e,(new o.Bc).appendText(m.kg("multipleResults","Click to show {0} definitions.",s.length)))}else{const e=s[0];if(!e.uri)return;this.textModelResolverService.createModelReference(e.uri).then((t=>{if(!t.object||!t.object.textEditorModel)return void t.dispose();const{object:{textEditorModel:i}}=t,{startLineNumber:s}=e.range;if(s<1||s>i.getLineCount())return void t.dispose();const n=this.getPreviewValue(i,s,e),r=this.languageService.guessLanguageIdByFilepathOrFirstLine(i.uri);this.addDecoration(a,n?(new o.Bc).appendCodeblock(r||"",n):void 0),t.dispose()}))}}getPreviewValue(e,t,i){let n=i.range;n.endLineNumber-n.startLineNumber>=s.MAX_SOURCE_PREVIEW_LINES&&(n=this.getPreviewRangeBasedOnIndentation(e,t));return this.stripIndentationFromPreviewRange(e,t,n)}stripIndentationFromPreviewRange(e,t,i){let s=e.getLineFirstNonWhitespaceColumn(t);for(let n=t+1;n{const i=!t&&this.editor.getOption(89)&&!this.isInPeekEditor(e);return new _.mR({openToSide:t,openInPeek:i,muteMessage:!0},{title:{value:"",original:""},id:"",precondition:void 0}).run(e)}))}isInPeekEditor(e){const t=e.get(f.fN);return p.x2.inPeekEditor.getValue(t)}dispose(){this.toUnhook.dispose(),this.toUnhookForKeyboard.dispose()}};y=s=E([S(1,u.ITextModelService),S(2,d.L),S(3,C.ILanguageFeaturesService)],y),(0,c.HW)(y.ID,y,2)},23646:(e,t,i)=>{"use strict";i.d(t,{X:()=>ce});var s,n=i(90766),r=i(64383),o=i(24939),a=i(5662),l=i(80301),c=i(83069),h=i(36677),d=i(84226),u=i(78209),g=i(50091),p=i(84001),m=i(32848),f=i(63591),_=i(59261),v=i(36584),C=i(58591),b=i(9711),E=i(79614),S=i(8597),y=i(35151),w=i(47661),L=i(41234),R=i(36456),T=i(89403),x=i(29163),k=i(87289),A=i(83941),N=i(18938),I=i(3828),O=i(37479),D=i(21852),M=i(26690),P=i(98031),F=i(67841),U=i(19070),H=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},B=function(e,t){return function(i,s){t(i,s,e)}};let W=class{constructor(e){this._resolverService=e}hasChildren(e){return e instanceof E.y4||e instanceof E.$L}getChildren(e){if(e instanceof E.y4)return e.groups;if(e instanceof E.$L)return e.resolve(this._resolverService).then((e=>e.children));throw new Error("bad tree")}};W=H([B(0,N.ITextModelService)],W);class V{getHeight(){return 23}getTemplateId(e){return e instanceof E.$L?K.id:q.id}}let z=class{constructor(e){this._keybindingService=e}getKeyboardNavigationLabel(e){if(e instanceof E.yc){const t=e.parent.getPreview(e)?.preview(e.range);if(t)return t.value}return(0,T.P8)(e.uri)}};z=H([B(0,P.b)],z);class G{getId(e){return e instanceof E.yc?e.id:e.uri}}let j=class extends a.jG{constructor(e,t){super(),this._labelService=t;const i=document.createElement("div");i.classList.add("reference-file"),this.file=this._register(new D.s(i,{supportHighlights:!0})),this.badge=new I.x(S.BC(i,S.$(".count")),{},U.m$),e.appendChild(i)}set(e,t){const i=(0,T.pD)(e.uri);this.file.setLabel(this._labelService.getUriBasenameLabel(e.uri),this._labelService.getUriLabel(i,{relative:!0}),{title:this._labelService.getUriLabel(e.uri),matches:t});const s=e.children.length;this.badge.setCount(s),s>1?this.badge.setTitleFormat((0,u.kg)("referencesCount","{0} references",s)):this.badge.setTitleFormat((0,u.kg)("referenceCount","{0} reference",s))}};j=H([B(1,F.L)],j);let K=class{static{s=this}static{this.id="FileReferencesRenderer"}constructor(e){this._instantiationService=e,this.templateId=s.id}renderTemplate(e){return this._instantiationService.createInstance(j,e)}renderElement(e,t,i){i.set(e.element,(0,M.WJ)(e.filterData))}disposeTemplate(e){e.dispose()}};K=s=H([B(0,f._Y)],K);class Y extends a.jG{constructor(e){super(),this.label=this._register(new O._(e))}set(e,t){const i=e.parent.getPreview(e)?.preview(e.range);if(i&&i.value){const{value:e,highlight:s}=i;t&&!M.ne.isDefault(t)?(this.label.element.classList.toggle("referenceMatch",!1),this.label.set(e,(0,M.WJ)(t))):(this.label.element.classList.toggle("referenceMatch",!0),this.label.set(e,[s]))}else this.label.set(`${(0,T.P8)(e.uri)}:${e.range.startLineNumber+1}:${e.range.startColumn+1}`)}}class q{constructor(){this.templateId=q.id}static{this.id="OneReferenceRenderer"}renderTemplate(e){return new Y(e)}renderElement(e,t,i){i.set(e.element,e.filterData)}disposeTemplate(e){e.dispose()}}class ${getWidgetAriaLabel(){return(0,u.kg)("treeAriaLabel","References")}getAriaLabel(e){return e.ariaMessage}}var Q=i(47612),X=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Z=function(e,t){return function(i,s){t(i,s,e)}};class J{static{this.DecorationOptions=k.kI.register({description:"reference-decoration",stickiness:1,className:"reference-decoration"})}constructor(e,t){this._editor=e,this._model=t,this._decorations=new Map,this._decorationIgnoreSet=new Set,this._callOnDispose=new a.Cm,this._callOnModelChange=new a.Cm,this._callOnDispose.add(this._editor.onDidChangeModel((()=>this._onModelChanged()))),this._onModelChanged()}dispose(){this._callOnModelChange.dispose(),this._callOnDispose.dispose(),this.removeDecorations()}_onModelChanged(){this._callOnModelChange.clear();const e=this._editor.getModel();if(e)for(const t of this._model.references)if(t.uri.toString()===e.uri.toString())return void this._addDecorations(t.parent)}_addDecorations(e){if(!this._editor.hasModel())return;this._callOnModelChange.add(this._editor.getModel().onDidChangeDecorations((()=>this._onDecorationChanged())));const t=[],i=[];for(let s=0,n=e.children.length;s{const n=s.deltaDecorations([],t);for(let t=0;t{e.equals(9)&&(this._keybindingService.dispatchEvent(e,e.target),e.stopPropagation())}),!0)),this._tree=this._instantiationService.createInstance(te,"ReferencesWidget",this._treeContainer,new V,[this._instantiationService.createInstance(K),this._instantiationService.createInstance(q)],this._instantiationService.createInstance(W),t),this._splitView.addView({onDidChange:L.Jh.None,element:this._previewContainer,minimumSize:200,maximumSize:Number.MAX_VALUE,layout:e=>{this._preview.layout({height:this._dim.height,width:e})}},y.X.Distribute),this._splitView.addView({onDidChange:L.Jh.None,element:this._treeContainer,minimumSize:100,maximumSize:Number.MAX_VALUE,layout:e=>{this._treeContainer.style.height=`${this._dim.height}px`,this._treeContainer.style.width=`${e}px`,this._tree.layout(this._dim.height,e)}},y.X.Distribute),this._disposables.add(this._splitView.onDidSashChange((()=>{this._dim.width&&(this.layoutData.ratio=this._splitView.getViewSize(0)/this._dim.width)}),void 0));const i=(e,t)=>{e instanceof E.yc&&("show"===t&&this._revealReference(e,!1),this._onDidSelectReference.fire({element:e,kind:t,source:"tree"}))};this._disposables.add(this._tree.onDidOpen((e=>{e.sideBySide?i(e.element,"side"):e.editorOptions.pinned?i(e.element,"goto"):i(e.element,"show")}))),S.jD(this._treeContainer)}_onWidth(e){this._dim&&this._doLayoutBody(this._dim.height,e)}_doLayoutBody(e,t){super._doLayoutBody(e,t),this._dim=new S.fg(t,e),this.layoutData.heightInLines=this._viewZone?this._viewZone.heightInLines:this.layoutData.heightInLines,this._splitView.layout(t),this._splitView.resizeView(0,t*this.layoutData.ratio)}setSelection(e){return this._revealReference(e,!0).then((()=>{this._model&&(this._tree.setSelection([e]),this._tree.setFocus([e]))}))}setModel(e){return this._disposeOnNewModel.clear(),this._model=e,this._model?this._onNewModel():Promise.resolve()}_onNewModel(){return this._model?this._model.isEmpty?(this.setTitle(""),this._messageContainer.innerText=u.kg("noResults","No results"),S.WU(this._messageContainer),Promise.resolve(void 0)):(S.jD(this._messageContainer),this._decorationsManager=new J(this._preview,this._model),this._disposeOnNewModel.add(this._decorationsManager),this._disposeOnNewModel.add(this._model.onDidChangeReferenceRange((e=>this._tree.rerender(e)))),this._disposeOnNewModel.add(this._preview.onMouseDown((e=>{const{event:t,target:i}=e;if(2!==t.detail)return;const s=this._getFocusedReference();s&&this._onDidSelectReference.fire({element:{uri:s.uri,range:i.range},kind:t.ctrlKey||t.metaKey||t.altKey?"side":"open",source:"editor"})}))),this.container.classList.add("results-loaded"),S.WU(this._treeContainer),S.WU(this._previewContainer),this._splitView.layout(this._dim.width),this.focusOnReferenceTree(),this._tree.setInput(1===this._model.groups.length?this._model.groups[0]:this._model)):Promise.resolve(void 0)}_getFocusedReference(){const[e]=this._tree.getFocus();return e instanceof E.yc?e:e instanceof E.$L&&e.children.length>0?e.children[0]:void 0}async revealReference(e){await this._revealReference(e,!1),this._onDidSelectReference.fire({element:e,kind:"goto",source:"tree"})}async _revealReference(e,t){if(this._revealedReference===e)return;this._revealedReference=e,e.uri.scheme!==R.ny.inMemory?this.setTitle((0,T.Pi)(e.uri),this._uriLabel.getUriLabel((0,T.pD)(e.uri))):this.setTitle(u.kg("peekView.alternateTitle","References"));const i=this._textModelResolverService.createModelReference(e.uri);this._tree.getInput()===e.parent||(t&&this._tree.reveal(e.parent),await this._tree.expand(e.parent)),this._tree.reveal(e);const s=await i;if(!this._model)return void s.dispose();(0,a.AS)(this._previewModelReference);const n=s.object;if(n){const t=this._preview.getModel()===n.textEditorModel?0:1,i=h.Q.lift(e.range).collapseToStart();this._previewModelReference=s,this._preview.setModel(n.textEditorModel),this._preview.setSelection(i),this._preview.revealRangeInCenter(i,t)}else this._preview.setModel(this._previewNotAvailableMessage),s.dispose()}};ie=X([Z(3,Q.Gy),Z(4,N.ITextModelService),Z(5,f._Y),Z(6,d.zn),Z(7,F.L),Z(8,P.b)],ie);var se,ne=i(60002),re=i(28290),oe=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ae=function(e,t){return function(i,s){t(i,s,e)}};const le=new m.N1("referenceSearchVisible",!1,u.kg("referenceSearchVisible","Whether reference peek is visible, like 'Peek References' or 'Peek Definition'"));let ce=class{static{se=this}static{this.ID="editor.contrib.referencesController"}static get(e){return e.getContribution(se.ID)}constructor(e,t,i,s,n,r,o,l){this._defaultTreeKeyboardSupport=e,this._editor=t,this._editorService=s,this._notificationService=n,this._instantiationService=r,this._storageService=o,this._configurationService=l,this._disposables=new a.Cm,this._requestIdPool=0,this._ignoreModelChangeEvent=!1,this._referenceSearchVisible=le.bindTo(i)}dispose(){this._referenceSearchVisible.reset(),this._disposables.dispose(),this._widget?.dispose(),this._model?.dispose(),this._widget=void 0,this._model=void 0}toggleWidget(e,t,i){let s;if(this._widget&&(s=this._widget.position),this.closeWidget(),s&&e.containsPosition(s))return;this._peekMode=i,this._referenceSearchVisible.set(!0),this._disposables.add(this._editor.onDidChangeModelLanguage((()=>{this.closeWidget()}))),this._disposables.add(this._editor.onDidChangeModel((()=>{this._ignoreModelChangeEvent||this.closeWidget()})));const n="peekViewLayout",r=ee.fromJSON(this._storageService.get(n,0,"{}"));this._widget=this._instantiationService.createInstance(ie,this._editor,this._defaultTreeKeyboardSupport,r),this._widget.setTitle(u.kg("labelLoading","Loading...")),this._widget.show(e),this._disposables.add(this._widget.onDidClose((()=>{t.cancel(),this._widget?(this._storageService.store(n,JSON.stringify(this._widget.layoutData),0,1),this._widget.isClosing||this.closeWidget(),this._widget=void 0):this.closeWidget()}))),this._disposables.add(this._widget.onDidSelectReference((e=>{const{element:t,kind:s}=e;if(t)switch(s){case"open":"editor"===e.source&&this._configurationService.getValue("editor.stablePeek")||this.openReference(t,!1,!1);break;case"side":this.openReference(t,!0,!1);break;case"goto":i?this._gotoReference(t,!0):this.openReference(t,!1,!0)}})));const o=++this._requestIdPool;t.then((t=>{if(o===this._requestIdPool&&this._widget)return this._model?.dispose(),this._model=t,this._widget.setModel(this._model).then((()=>{if(this._widget&&this._model&&this._editor.hasModel()){this._model.isEmpty?this._widget.setMetaTitle(""):this._widget.setMetaTitle(u.kg("metaTitle.N","{0} ({1})",this._model.title,this._model.references.length));const t=this._editor.getModel().uri,i=new c.y(e.startLineNumber,e.startColumn),s=this._model.nearestReference(t,i);if(s)return this._widget.setSelection(s).then((()=>{this._widget&&"editor"===this._editor.getOption(87)&&this._widget.focusOnPreviewEditor()}))}}));t.dispose()}),(e=>{this._notificationService.error(e)}))}changeFocusBetweenPreviewAndReferences(){this._widget&&(this._widget.isPreviewEditorFocused()?this._widget.focusOnReferenceTree():this._widget.focusOnPreviewEditor())}async goToNextOrPreviousReference(e){if(!this._editor.hasModel()||!this._model||!this._widget)return;const t=this._widget.position;if(!t)return;const i=this._model.nearestReference(this._editor.getModel().uri,t);if(!i)return;const s=this._model.nextOrPreviousReference(i,e),n=this._editor.hasTextFocus(),r=this._widget.isPreviewEditorFocused();await this._widget.setSelection(s),await this._gotoReference(s,!1),n?this._editor.focus():this._widget&&r&&this._widget.focusOnPreviewEditor()}async revealReference(e){this._editor.hasModel()&&this._model&&this._widget&&await this._widget.revealReference(e)}closeWidget(e=!0){this._widget?.dispose(),this._model?.dispose(),this._referenceSearchVisible.reset(),this._disposables.clear(),this._widget=void 0,this._model=void 0,e&&this._editor.focus(),this._requestIdPool+=1}_gotoReference(e,t){this._widget?.hide(),this._ignoreModelChangeEvent=!0;const i=h.Q.lift(e.range).collapseToStart();return this._editorService.openCodeEditor({resource:e.uri,options:{selection:i,selectionSource:"code.jump",pinned:t}},this._editor).then((e=>{if(this._ignoreModelChangeEvent=!1,e&&this._widget)if(this._editor===e)this._widget.show(i),this._widget.focusOnReferenceTree();else{const t=se.get(e),s=this._model.clone();this.closeWidget(),e.focus(),t?.toggleWidget(i,(0,n.SS)((e=>Promise.resolve(s))),this._peekMode??!1)}else this.closeWidget()}),(e=>{this._ignoreModelChangeEvent=!1,(0,r.dz)(e)}))}openReference(e,t,i){t||this.closeWidget();const{uri:s,range:n}=e;this._editorService.openCodeEditor({resource:s,options:{selection:n,selectionSource:"code.jump",pinned:i}},this._editor,t)}};function he(e,t){const i=(0,d.RL)(e);if(!i)return;const s=ce.get(i);s&&t(s)}ce=se=oe([ae(2,m.fN),ae(3,l.T),ae(4,C.Ot),ae(5,f._Y),ae(6,b.CS),ae(7,p.pG)],ce),_.f.registerCommandAndKeybindingRule({id:"togglePeekWidgetFocus",weight:100,primary:(0,o.m5)(2089,60),when:m.M$.or(le,d.x2.inPeekEditor),handler(e){he(e,(e=>{e.changeFocusBetweenPreviewAndReferences()}))}}),_.f.registerCommandAndKeybindingRule({id:"goToNextReference",weight:90,primary:62,secondary:[70],when:m.M$.or(le,d.x2.inPeekEditor),handler(e){he(e,(e=>{e.goToNextOrPreviousReference(!0)}))}}),_.f.registerCommandAndKeybindingRule({id:"goToPreviousReference",weight:90,primary:1086,secondary:[1094],when:m.M$.or(le,d.x2.inPeekEditor),handler(e){he(e,(e=>{e.goToNextOrPreviousReference(!1)}))}}),g.w.registerCommandAlias("goToNextReferenceFromEmbeddedEditor","goToNextReference"),g.w.registerCommandAlias("goToPreviousReferenceFromEmbeddedEditor","goToPreviousReference"),g.w.registerCommandAlias("closeReferenceSearchEditor","closeReferenceSearch"),g.w.registerCommand("closeReferenceSearch",(e=>he(e,(e=>e.closeWidget())))),_.f.registerKeybindingRule({id:"closeReferenceSearch",weight:-1,primary:9,secondary:[1033],when:m.M$.and(d.x2.inPeekEditor,m.M$.not("config.editor.stablePeek"))}),_.f.registerKeybindingRule({id:"closeReferenceSearch",weight:250,primary:9,secondary:[1033],when:m.M$.and(le,m.M$.not("config.editor.stablePeek"),m.M$.or(ne.R.editorTextFocus,re.J7.negate()))}),_.f.registerCommandAndKeybindingRule({id:"revealReference",weight:200,primary:3,mac:{primary:3,secondary:[2066]},when:m.M$.and(le,v.YD,v.Nf.negate(),v.cH.negate()),handler(e){const t=e.get(v.PE),i=t.lastFocusedList?.getFocus();Array.isArray(i)&&i[0]instanceof E.yc&&he(e,(e=>e.revealReference(i[0])))}}),_.f.registerCommandAndKeybindingRule({id:"openReferenceToSide",weight:100,primary:2051,mac:{primary:259},when:m.M$.and(le,v.YD,v.Nf.negate(),v.cH.negate()),handler(e){const t=e.get(v.PE),i=t.lastFocusedList?.getFocus();Array.isArray(i)&&i[0]instanceof E.yc&&he(e,(e=>e.openReference(i[0],!0,!0)))}}),g.w.registerCommand("openReference",(e=>{const t=e.get(v.PE),i=t.lastFocusedList?.getFocus();Array.isArray(i)&&i[0]instanceof E.yc&&he(e,(e=>e.openReference(i[0],!1,!0)))}))},79614:(e,t,i)=>{"use strict";i.d(t,{$L:()=>p,y4:()=>m,yc:()=>u});var s=i(64383),n=i(41234),r=i(96032),o=i(5662),a=i(74320),l=i(89403),c=i(91508),h=i(36677),d=i(78209);class u{constructor(e,t,i,s){this.isProviderFirst=e,this.parent=t,this.link=i,this._rangeCallback=s,this.id=r.r.nextId()}get uri(){return this.link.uri}get range(){return this._range??this.link.targetSelectionRange??this.link.range}set range(e){this._range=e,this._rangeCallback(this)}get ariaMessage(){const e=this.parent.getPreview(this)?.preview(this.range);return e?(0,d.kg)({key:"aria.oneReference.preview",comment:["Placeholders are: 0: filename, 1:line number, 2: column number, 3: preview snippet of source code"]},"{0} in {1} on line {2} at column {3}",e.value,(0,l.P8)(this.uri),this.range.startLineNumber,this.range.startColumn):(0,d.kg)("aria.oneReference","in {0} on line {1} at column {2}",(0,l.P8)(this.uri),this.range.startLineNumber,this.range.startColumn)}}class g{constructor(e){this._modelReference=e}dispose(){this._modelReference.dispose()}preview(e,t=8){const i=this._modelReference.object.textEditorModel;if(!i)return;const{startLineNumber:s,startColumn:n,endLineNumber:r,endColumn:o}=e,a=i.getWordUntilPosition({lineNumber:s,column:n-t}),l=new h.Q(s,a.startColumn,s,n),c=new h.Q(r,o,r,1073741824),d=i.getValueInRange(l).replace(/^\s+/,""),u=i.getValueInRange(e);return{value:d+u+i.getValueInRange(c).replace(/\s+$/,""),highlight:{start:d.length,end:d.length+u.length}}}}class p{constructor(e,t){this.parent=e,this.uri=t,this.children=[],this._previews=new a.fT}dispose(){(0,o.AS)(this._previews.values()),this._previews.clear()}getPreview(e){return this._previews.get(e.uri)}get ariaMessage(){const e=this.children.length;return 1===e?(0,d.kg)("aria.fileReferences.1","1 symbol in {0}, full path {1}",(0,l.P8)(this.uri),this.uri.fsPath):(0,d.kg)("aria.fileReferences.N","{0} symbols in {1}, full path {2}",e,(0,l.P8)(this.uri),this.uri.fsPath)}async resolve(e){if(0!==this._previews.size)return this;for(const i of this.children)if(!this._previews.has(i.uri))try{const t=await e.createModelReference(i.uri);this._previews.set(i.uri,new g(t))}catch(t){(0,s.dz)(t)}return this}}class m{constructor(e,t){this.groups=[],this.references=[],this._onDidChangeReferenceRange=new n.vl,this.onDidChangeReferenceRange=this._onDidChangeReferenceRange.event,this._links=e,this._title=t;const[i]=e;let s;e.sort(m._compareReferences);for(const n of e)if(s&&l.er.isEqual(s.uri,n.uri,!0)||(s=new p(this,n.uri),this.groups.push(s)),0===s.children.length||0!==m._compareReferences(n,s.children[s.children.length-1])){const e=new u(i===n,s,n,(e=>this._onDidChangeReferenceRange.fire(e)));this.references.push(e),s.children.push(e)}}dispose(){(0,o.AS)(this.groups),this._onDidChangeReferenceRange.dispose(),this.groups.length=0}clone(){return new m(this._links,this._title)}get title(){return this._title}get isEmpty(){return 0===this.groups.length}get ariaMessage(){return this.isEmpty?(0,d.kg)("aria.result.0","No results found"):1===this.references.length?(0,d.kg)("aria.result.1","Found 1 symbol in {0}",this.references[0].uri.fsPath):1===this.groups.length?(0,d.kg)("aria.result.n1","Found {0} symbols in {1}",this.references.length,this.groups[0].uri.fsPath):(0,d.kg)("aria.result.nm","Found {0} symbols in {1} files",this.references.length,this.groups.length)}nextOrPreviousReference(e,t){const{parent:i}=e;let s=i.children.indexOf(e);const n=i.children.length,r=i.parent.groups.length;return 1===r||t&&s+10?(s=t?(s+1)%n:(s+n-1)%n,i.children[s]):(s=i.parent.groups.indexOf(i),t?(s=(s+1)%r,i.parent.groups[s].children[0]):(s=(s+r-1)%r,i.parent.groups[s].children[i.parent.groups[s].children.length-1]))}nearestReference(e,t){const i=this.references.map(((i,s)=>({idx:s,prefixLen:c.Qp(i.uri.toString(),e.toString()),offsetDist:100*Math.abs(i.range.startLineNumber-t.lineNumber)+Math.abs(i.range.startColumn-t.column)}))).sort(((e,t)=>e.prefixLen>t.prefixLen?-1:e.prefixLent.offsetDist?1:0))[0];if(i)return this.references[i.idx]}referenceAt(e,t){for(const i of this.references)if(i.uri.toString()===e.toString()&&h.Q.containsPosition(i.range,t))return i}firstReference(){for(const e of this.references)if(e.isProviderFirst)return e;return this.references[0]}static _compareReferences(e,t){return l.er.compare(e.uri,t.uri)||h.Q.compareRangesUsingStarts(e.range,t.range)}}},77011:(e,t,i)=>{"use strict";i.d(t,{A:()=>q});var s=i(87758),n=i(5662),r=i(63591),o=i(64317),a=i(98031),l=i(90766),c=i(51219),h=i(8597),d=i(62083),u=i(12143),g=i(57039),p=i(88807),m=i(83069);class f extends n.jG{constructor(e,t=new h.fg(10,10)){super(),this._editor=e,this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this._resizableNode=this._register(new p.v),this._contentPosition=null,this._isResizing=!1,this._resizableNode.domNode.style.position="absolute",this._resizableNode.minSize=h.fg.lift(t),this._resizableNode.layout(t.height,t.width),this._resizableNode.enableSashes(!0,!0,!0,!0),this._register(this._resizableNode.onDidResize((e=>{this._resize(new h.fg(e.dimension.width,e.dimension.height)),e.done&&(this._isResizing=!1)}))),this._register(this._resizableNode.onDidWillResize((()=>{this._isResizing=!0})))}get isResizing(){return this._isResizing}getDomNode(){return this._resizableNode.domNode}getPosition(){return this._contentPosition}get position(){return this._contentPosition?.position?m.y.lift(this._contentPosition.position):void 0}_availableVerticalSpaceAbove(e){const t=this._editor.getDomNode(),i=this._editor.getScrolledVisiblePosition(e);if(!t||!i)return;return h.BK(t).top+i.top-30}_availableVerticalSpaceBelow(e){const t=this._editor.getDomNode(),i=this._editor.getScrolledVisiblePosition(e);if(!t||!i)return;const s=h.BK(t),n=h.tG(t.ownerDocument.body),r=s.top+i.top+i.height;return n.height-r-24}_findPositionPreference(e,t){const i=Math.min(this._availableVerticalSpaceBelow(t)??1/0,e),s=Math.min(this._availableVerticalSpaceAbove(t)??1/0,e),n=Math.min(Math.max(s,i),e),r=Math.min(e,n);let o;return o=this._editor.getOption(60).above?r<=s?1:2:r<=i?2:1,1===o?this._resizableNode.enableSashes(!0,!0,!1,!1):this._resizableNode.enableSashes(!1,!0,!0,!1),o}_resize(e){this._resizableNode.layout(e.height,e.width)}}var _,v=i(32848),C=i(84001),b=i(253),E=i(60002),S=i(52776),y=i(41234),w=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},L=function(e,t){return function(i,s){t(i,s,e)}};let R=class extends f{static{_=this}static{this.ID="editor.contrib.resizableContentHoverWidget"}static{this._lastDimensions=new h.fg(0,0)}get isVisibleFromKeyboard(){return 1===this._renderedHover?.source}get isVisible(){return this._hoverVisibleKey.get()??!1}get isFocused(){return this._hoverFocusedKey.get()??!1}constructor(e,t,i,s,n){const r=e.getOption(67)+8,o=new h.fg(150,r);super(e,o),this._configurationService=i,this._accessibilityService=s,this._keybindingService=n,this._hover=this._register(new S.N4),this._onDidResize=this._register(new y.vl),this.onDidResize=this._onDidResize.event,this._minimumSize=o,this._hoverVisibleKey=E.R.hoverVisible.bindTo(t),this._hoverFocusedKey=E.R.hoverFocused.bindTo(t),h.BC(this._resizableNode.domNode,this._hover.containerDomNode),this._resizableNode.domNode.style.zIndex="50",this._register(this._editor.onDidLayoutChange((()=>{this.isVisible&&this._updateMaxDimensions()}))),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(50)&&this._updateFont()})));const a=this._register(h.w5(this._resizableNode.domNode));this._register(a.onDidFocus((()=>{this._hoverFocusedKey.set(!0)}))),this._register(a.onDidBlur((()=>{this._hoverFocusedKey.set(!1)}))),this._setRenderedHover(void 0),this._editor.addContentWidget(this)}dispose(){super.dispose(),this._renderedHover?.dispose(),this._editor.removeContentWidget(this)}getId(){return _.ID}static _applyDimensions(e,t,i){const s="number"===typeof t?`${t}px`:t,n="number"===typeof i?`${i}px`:i;e.style.width=s,e.style.height=n}_setContentsDomNodeDimensions(e,t){const i=this._hover.contentsDomNode;return _._applyDimensions(i,e,t)}_setContainerDomNodeDimensions(e,t){const i=this._hover.containerDomNode;return _._applyDimensions(i,e,t)}_setHoverWidgetDimensions(e,t){this._setContentsDomNodeDimensions(e,t),this._setContainerDomNodeDimensions(e,t),this._layoutContentWidget()}static _applyMaxDimensions(e,t,i){const s="number"===typeof t?`${t}px`:t,n="number"===typeof i?`${i}px`:i;e.style.maxWidth=s,e.style.maxHeight=n}_setHoverWidgetMaxDimensions(e,t){_._applyMaxDimensions(this._hover.contentsDomNode,e,t),_._applyMaxDimensions(this._hover.containerDomNode,e,t),this._hover.containerDomNode.style.setProperty("--vscode-hover-maxWidth","number"===typeof e?`${e}px`:e),this._layoutContentWidget()}_setAdjustedHoverWidgetDimensions(e){this._setHoverWidgetMaxDimensions("none","none");const t=e.width,i=e.height;this._setHoverWidgetDimensions(t,i)}_updateResizableNodeMaxDimensions(){const e=this._findMaximumRenderingWidth()??1/0,t=this._findMaximumRenderingHeight()??1/0;this._resizableNode.maxSize=new h.fg(e,t),this._setHoverWidgetMaxDimensions(e,t)}_resize(e){_._lastDimensions=new h.fg(e.width,e.height),this._setAdjustedHoverWidgetDimensions(e),this._resizableNode.layout(e.height,e.width),this._updateResizableNodeMaxDimensions(),this._hover.scrollbar.scanDomNode(),this._editor.layoutContentWidget(this),this._onDidResize.fire()}_findAvailableSpaceVertically(){const e=this._renderedHover?.showAtPosition;if(e)return 1===this._positionPreference?this._availableVerticalSpaceAbove(e):this._availableVerticalSpaceBelow(e)}_findMaximumRenderingHeight(){const e=this._findAvailableSpaceVertically();if(!e)return;let t=6;return Array.from(this._hover.contentsDomNode.children).forEach((e=>{t+=e.clientHeight})),Math.min(e,t)}_isHoverTextOverflowing(){this._hover.containerDomNode.style.setProperty("--vscode-hover-whiteSpace","nowrap"),this._hover.containerDomNode.style.setProperty("--vscode-hover-sourceWhiteSpace","nowrap");const e=Array.from(this._hover.contentsDomNode.children).some((e=>e.scrollWidth>e.clientWidth));return this._hover.containerDomNode.style.removeProperty("--vscode-hover-whiteSpace"),this._hover.containerDomNode.style.removeProperty("--vscode-hover-sourceWhiteSpace"),e}_findMaximumRenderingWidth(){if(!this._editor||!this._editor.hasModel())return;const e=this._isHoverTextOverflowing(),t="undefined"===typeof this._contentWidth?0:this._contentWidth-2;if(e||this._hover.containerDomNode.clientWidththis._renderedHover.closestMouseDistance+4)&&(this._renderedHover.closestMouseDistance=Math.min(this._renderedHover.closestMouseDistance,s),!0)}_setRenderedHover(e){this._renderedHover?.dispose(),this._renderedHover=e,this._hoverVisibleKey.set(!!e),this._hover.containerDomNode.classList.toggle("hidden",!e)}_updateFont(){const{fontSize:e,lineHeight:t}=this._editor.getOption(50),i=this._hover.contentsDomNode;i.style.fontSize=`${e}px`,i.style.lineHeight=""+t/e;Array.prototype.slice.call(this._hover.contentsDomNode.getElementsByClassName("code")).forEach((e=>this._editor.applyFontInfo(e)))}_updateContent(e){const t=this._hover.contentsDomNode;t.style.paddingBottom="",t.textContent="",t.appendChild(e)}_layoutContentWidget(){this._editor.layoutContentWidget(this),this._hover.onContentsChanged()}_updateMaxDimensions(){const e=Math.max(this._editor.getLayoutInfo().height/4,250,_._lastDimensions.height),t=Math.max(.66*this._editor.getLayoutInfo().width,500,_._lastDimensions.width);this._setHoverWidgetMaxDimensions(t,e)}_render(e){this._setRenderedHover(e),this._updateFont(),this._updateContent(e.domNode),this._updateMaxDimensions(),this.onContentsChanged(),this._editor.render()}getPosition(){return this._renderedHover?{position:this._renderedHover.showAtPosition,secondaryPosition:this._renderedHover.showAtSecondaryPosition,positionAffinity:this._renderedHover.shouldAppearBeforeContent?3:void 0,preference:[this._positionPreference??1]}:null}show(e){if(!this._editor||!this._editor.hasModel())return;this._render(e);const t=h.OK(this._hover.containerDomNode),i=e.showAtPosition;this._positionPreference=this._findPositionPreference(t,i)??1,this.onContentsChanged(),e.shouldFocus&&this._hover.containerDomNode.focus(),this._onDidResize.fire();const s=this._hover.containerDomNode.ownerDocument.activeElement===this._hover.containerDomNode&&(0,S.vr)(!0===this._configurationService.getValue("accessibility.verbosity.hover")&&this._accessibilityService.isScreenReaderOptimized(),this._keybindingService.lookupKeybinding("editor.action.accessibleView")?.getAriaLabel()??"");s&&(this._hover.contentsDomNode.ariaLabel=this._hover.contentsDomNode.textContent+", "+s)}hide(){if(!this._renderedHover)return;const e=this._renderedHover.shouldFocus||this._hoverFocusedKey.get();this._setRenderedHover(void 0),this._resizableNode.maxSize=new h.fg(1/0,1/0),this._resizableNode.clearSashHoverState(),this._hoverFocusedKey.set(!1),this._editor.layoutContentWidget(this),e&&this._editor.focus()}_removeConstraintsRenderNormally(){const e=this._editor.getLayoutInfo();this._resizableNode.layout(e.height,e.width),this._setHoverWidgetDimensions("auto","auto")}setMinimumDimensions(e){this._minimumSize=new h.fg(Math.max(this._minimumSize.width,e.width),Math.max(this._minimumSize.height,e.height)),this._updateMinimumWidth()}_updateMinimumWidth(){const e="undefined"===typeof this._contentWidth?this._minimumSize.width:Math.min(this._contentWidth,this._minimumSize.width);this._resizableNode.minSize=new h.fg(e,this._minimumSize.height)}onContentsChanged(){this._removeConstraintsRenderNormally();const e=this._hover.containerDomNode;let t=h.OK(e),i=h.Tr(e);if(this._resizableNode.layout(t,i),this._setHoverWidgetDimensions(i,t),t=h.OK(e),i=h.Tr(e),this._contentWidth=i,this._updateMinimumWidth(),this._resizableNode.layout(t,i),this._renderedHover?.showAtPosition){const e=h.OK(this._hover.containerDomNode);this._positionPreference=this._findPositionPreference(e,this._renderedHover.showAtPosition)}this._layoutContentWidget()}focus(){this._hover.containerDomNode.focus()}scrollUp(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._editor.getOption(50);this._hover.scrollbar.setScrollPosition({scrollTop:e-t.lineHeight})}scrollDown(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._editor.getOption(50);this._hover.scrollbar.setScrollPosition({scrollTop:e+t.lineHeight})}scrollLeft(){const e=this._hover.scrollbar.getScrollPosition().scrollLeft;this._hover.scrollbar.setScrollPosition({scrollLeft:e-30})}scrollRight(){const e=this._hover.scrollbar.getScrollPosition().scrollLeft;this._hover.scrollbar.setScrollPosition({scrollLeft:e+30})}pageUp(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._hover.scrollbar.getScrollDimensions().height;this._hover.scrollbar.setScrollPosition({scrollTop:e-t})}pageDown(){const e=this._hover.scrollbar.getScrollPosition().scrollTop,t=this._hover.scrollbar.getScrollDimensions().height;this._hover.scrollbar.setScrollPosition({scrollTop:e+t})}goToTop(){this._hover.scrollbar.setScrollPosition({scrollTop:0})}goToBottom(){this._hover.scrollbar.setScrollPosition({scrollTop:this._hover.scrollbar.getScrollDimensions().scrollHeight})}};function T(e,t,i,s,n,r){const o=i+n/2,a=s+r/2,l=Math.max(Math.abs(e-o)-n/2,0),c=Math.max(Math.abs(t-a)-r/2,0);return Math.sqrt(l*l+c*c)}R=_=w([L(1,v.fN),L(2,C.pG),L(3,b.j),L(4,a.b)],R);var x=i(25890);class k{get anchor(){return this._anchor}set anchor(e){this._anchor=e}get shouldFocus(){return this._shouldFocus}set shouldFocus(e){this._shouldFocus=e}get source(){return this._source}set source(e){this._source=e}get insistOnKeepingHoverVisible(){return this._insistOnKeepingHoverVisible}set insistOnKeepingHoverVisible(e){this._insistOnKeepingHoverVisible=e}constructor(e,t){this._editor=e,this._participants=t,this._anchor=null,this._shouldFocus=!1,this._source=0,this._insistOnKeepingHoverVisible=!1}static _getLineDecorations(e,t){if(1!==t.type&&!t.supportsMarkerHover)return[];const i=e.getModel(),s=t.range.startLineNumber;if(s>i.getLineCount())return[];const n=i.getLineMaxColumn(s);return e.getLineDecorations(s).filter((e=>{if(e.options.isWholeLine)return!0;const i=e.range.startLineNumber===s?e.range.startColumn:1,r=e.range.endLineNumber===s?e.range.endColumn:n;if(e.options.showIfCollapsed){if(i>t.range.startColumn+1||t.range.endColumn-1>r)return!1}else if(i>t.range.startColumn||t.range.endColumn>r)return!1;return!0}))}computeAsync(e){const t=this._anchor;if(!this._editor.hasModel()||!t)return l.AE.EMPTY;const i=k._getLineDecorations(this._editor,t);return l.AE.merge(this._participants.map((s=>s.computeAsync?s.computeAsync(t,i,e):l.AE.EMPTY)))}computeSync(){if(!this._editor.hasModel()||!this._anchor)return[];const e=k._getLineDecorations(this._editor,this._anchor);let t=[];for(const i of this._participants)t=t.concat(i.computeSync(this._anchor,e));return(0,x.Yc)(t)}}class A{constructor(e,t,i){this.anchor=e,this.hoverParts=t,this.isComplete=i}filter(e){const t=this.hoverParts.filter((t=>t.isValidForHoverAnchor(e)));return t.length===this.hoverParts.length?this:new N(this,this.anchor,t,this.isComplete)}}class N extends A{constructor(e,t,i,s){super(t,i,s),this.original=e}filter(e){return this.original.filter(e)}}var I=i(9270),O=i(87289),D=i(36677),M=i(57286),P=i(28712),F=i(68250),U=i(64383);class H extends n.jG{constructor(e,t,i,s,n,r){super();const o=t.anchor,a=t.hoverParts;this._renderedHoverParts=this._register(new W(e,i,a,r,n));const{showAtPosition:l,showAtSecondaryPosition:c}=H.computeHoverPositions(e,o.range,a);this.shouldAppearBeforeContent=a.some((e=>e.isBeforeContent)),this.showAtPosition=l,this.showAtSecondaryPosition=c,this.initialMousePosX=o.initialMousePosX,this.initialMousePosY=o.initialMousePosY,this.shouldFocus=s.shouldFocus,this.source=s.source}get domNode(){return this._renderedHoverParts.domNode}get domNodeHasChildren(){return this._renderedHoverParts.domNodeHasChildren}get focusedHoverPartIndex(){return this._renderedHoverParts.focusedHoverPartIndex}async updateHoverVerbosityLevel(e,t,i){this._renderedHoverParts.updateHoverVerbosityLevel(e,t,i)}isColorPickerVisible(){return this._renderedHoverParts.isColorPickerVisible()}static computeHoverPositions(e,t,i){let s=1;if(e.hasModel()){const i=e._getViewModel(),n=i.coordinatesConverter,r=n.convertModelRangeToViewRange(t),o=i.getLineMinColumn(r.startLineNumber),a=new m.y(r.startLineNumber,o);s=n.convertViewPositionToModelPosition(a).column}const n=t.startLineNumber;let r,o,a,l=t.startColumn;for(const c of i){const e=c.range,t=e.startLineNumber===n,i=e.endLineNumber===n;if(t&&i){const t=e.startColumn,i=Math.min(l,t);l=Math.max(i,s)}c.forceShowAtRange&&(r=e)}if(r){const e=r.getStartPosition();o=e,a=e}else o=t.getStartPosition(),a=new m.y(n,l);return{showAtPosition:o,showAtSecondaryPosition:a}}}class B{constructor(e,t){this._statusBar=t,e.appendChild(this._statusBar.hoverElement)}get hoverElement(){return this._statusBar.hoverElement}get actions(){return this._statusBar.actions}dispose(){this._statusBar.dispose()}}class W extends n.jG{static{this._DECORATION_OPTIONS=O.kI.register({description:"content-hover-highlight",className:"hoverHighlight"})}constructor(e,t,i,s,n){super(),this._renderedParts=[],this._focusedHoverPartIndex=-1,this._context=n,this._fragment=document.createDocumentFragment(),this._register(this._renderParts(t,i,n,s)),this._register(this._registerListenersOnRenderedParts()),this._register(this._createEditorDecorations(e,i)),this._updateMarkdownAndColorParticipantInfo(t)}_createEditorDecorations(e,t){if(0===t.length)return n.jG.None;let i=t[0].range;for(const n of t){const e=n.range;i=D.Q.plusRange(i,e)}const s=e.createDecorationsCollection();return s.set([{range:i,options:W._DECORATION_OPTIONS}]),(0,n.s)((()=>{s.clear()}))}_renderParts(e,t,i,s){const r=new I.L(s),o={fragment:this._fragment,statusBar:r,...i},a=new n.Cm;for(const n of e){const e=this._renderHoverPartsForParticipant(t,n,o);a.add(e);for(const t of e.renderedHoverParts)this._renderedParts.push({type:"hoverPart",participant:n,hoverPart:t.hoverPart,hoverElement:t.hoverElement})}const l=this._renderStatusBar(this._fragment,r);return l&&(a.add(l),this._renderedParts.push({type:"statusBar",hoverElement:l.hoverElement,actions:l.actions})),(0,n.s)((()=>{a.dispose()}))}_renderHoverPartsForParticipant(e,t,i){const s=e.filter((e=>e.owner===t));return s.length>0?t.renderHoverParts(i,s):new g.Ke([])}_renderStatusBar(e,t){if(t.hasContent)return new B(e,t)}_registerListenersOnRenderedParts(){const e=new n.Cm;return this._renderedParts.forEach(((t,i)=>{const s=t.hoverElement;s.tabIndex=0,e.add(h.ko(s,h.Bx.FOCUS_IN,(e=>{e.stopPropagation(),this._focusedHoverPartIndex=i}))),e.add(h.ko(s,h.Bx.FOCUS_OUT,(e=>{e.stopPropagation(),this._focusedHoverPartIndex=-1})))})),e}_updateMarkdownAndColorParticipantInfo(e){const t=e.find((e=>e instanceof M.xJ&&!(e instanceof F.u)));t&&(this._markdownHoverParticipant=t),this._colorHoverParticipant=e.find((e=>e instanceof P.BJ))}async updateHoverVerbosityLevel(e,t,i){if(!this._markdownHoverParticipant)return;const s=this._normalizedIndexToMarkdownHoverIndexRange(this._markdownHoverParticipant,t);if(void 0===s)return;const n=await this._markdownHoverParticipant.updateMarkdownHoverVerbosityLevel(e,s,i);n&&(this._renderedParts[t]={type:"hoverPart",participant:this._markdownHoverParticipant,hoverPart:n.hoverPart,hoverElement:n.hoverElement},this._context.onContentsChanged())}isColorPickerVisible(){return this._colorHoverParticipant?.isColorPickerVisible()??!1}_normalizedIndexToMarkdownHoverIndexRange(e,t){const i=this._renderedParts[t];if(!i||"hoverPart"!==i.type)return;if(!(i.participant===e))return;const s=this._renderedParts.findIndex((t=>"hoverPart"===t.type&&t.participant===e));if(-1===s)throw new U.D7;return t-s}get domNode(){return this._fragment}get domNodeHasChildren(){return this._fragment.hasChildNodes()}get focusedHoverPartIndex(){return this._focusedHoverPartIndex}}var V=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};let G=class extends n.jG{constructor(e,t,i){super(),this._editor=e,this._instantiationService=t,this._keybindingService=i,this._currentResult=null,this._onContentsChanged=this._register(new y.vl),this.onContentsChanged=this._onContentsChanged.event,this._contentHoverWidget=this._register(this._instantiationService.createInstance(R,this._editor)),this._participants=this._initializeHoverParticipants(),this._computer=new k(this._editor,this._participants),this._hoverOperation=this._register(new u.w(this._editor,this._computer)),this._registerListeners()}_initializeHoverParticipants(){const e=[];for(const t of g.B2.getAll()){const i=this._instantiationService.createInstance(t,this._editor);e.push(i)}return e.sort(((e,t)=>e.hoverOrdinal-t.hoverOrdinal)),this._register(this._contentHoverWidget.onDidResize((()=>{this._participants.forEach((e=>e.handleResize?.()))}))),e}_registerListeners(){this._register(this._hoverOperation.onResult((e=>{if(!this._computer.anchor)return;const t=e.hasLoadingMessage?this._addLoadingMessage(e.value):e.value;this._withResult(new A(this._computer.anchor,t,e.isComplete))})));const e=this._contentHoverWidget.getDomNode();this._register(h.b2(e,"keydown",(e=>{e.equals(9)&&this.hide()}))),this._register(h.b2(e,"mouseleave",(e=>{this._onMouseLeave(e)}))),this._register(d.dG.onDidChange((()=>{this._contentHoverWidget.position&&this._currentResult&&this._setCurrentResult(this._currentResult)})))}_startShowingOrUpdateHover(e,t,i,s,n){if(!(this._contentHoverWidget.position&&this._currentResult))return!!e&&(this._startHoverOperationIfNecessary(e,t,i,s,!1),!0);const r=this._editor.getOption(60).sticky,o=n&&this._contentHoverWidget.isMouseGettingCloser(n.event.posx,n.event.posy);if(r&&o)return e&&this._startHoverOperationIfNecessary(e,t,i,s,!0),!0;if(!e)return this._setCurrentResult(null),!1;if(this._currentResult.anchor.equals(e))return!0;return e.canAdoptVisibleHover(this._currentResult.anchor,this._contentHoverWidget.position)?(this._setCurrentResult(this._currentResult.filter(e)),this._startHoverOperationIfNecessary(e,t,i,s,!1),!0):(this._setCurrentResult(null),this._startHoverOperationIfNecessary(e,t,i,s,!1),!0)}_startHoverOperationIfNecessary(e,t,i,s,n){this._computer.anchor&&this._computer.anchor.equals(e)||(this._hoverOperation.cancel(),this._computer.anchor=e,this._computer.shouldFocus=s,this._computer.source=i,this._computer.insistOnKeepingHoverVisible=n,this._hoverOperation.start(t))}_setCurrentResult(e){let t=e;if(this._currentResult===t)return;t&&0===t.hoverParts.length&&(t=null),this._currentResult=t,this._currentResult?this._showHover(this._currentResult):this._hideHover()}_addLoadingMessage(e){if(!this._computer.anchor)return e;for(const t of this._participants){if(!t.createLoadingMessage)continue;const i=t.createLoadingMessage(this._computer.anchor);if(i)return e.slice(0).concat([i])}return e}_withResult(e){this._contentHoverWidget.position&&this._currentResult&&this._currentResult.isComplete||this._setCurrentResult(e);if(!e.isComplete)return;const t=0===e.hoverParts.length,i=this._computer.insistOnKeepingHoverVisible;t&&i||this._setCurrentResult(e)}_showHover(e){const t=this._getHoverContext();this._renderedContentHover=new H(this._editor,e,this._participants,this._computer,t,this._keybindingService),this._renderedContentHover.domNodeHasChildren?this._contentHoverWidget.show(this._renderedContentHover):this._renderedContentHover.dispose()}_hideHover(){this._contentHoverWidget.hide()}_getHoverContext(){return{hide:()=>{this.hide()},onContentsChanged:()=>{this._onContentsChanged.fire(),this._contentHoverWidget.onContentsChanged()},setMinimumDimensions:e=>{this._contentHoverWidget.setMinimumDimensions(e)}}}showsOrWillShow(e){if(this._contentHoverWidget.isResizing)return!0;const t=this._findHoverAnchorCandidates(e);if(!(t.length>0))return this._startShowingOrUpdateHover(null,0,0,!1,e);const i=t[0];return this._startShowingOrUpdateHover(i,0,0,!1,e)}_findHoverAnchorCandidates(e){const t=[];for(const s of this._participants){if(!s.suggestHoverAnchor)continue;const i=s.suggestHoverAnchor(e);i&&t.push(i)}const i=e.target;switch(i.type){case 6:t.push(new g.hx(0,i.range,e.event.posx,e.event.posy));break;case 7:{const s=this._editor.getOption(50).typicalHalfwidthCharacterWidth/2;if(!(!i.detail.isAfterLines&&"number"===typeof i.detail.horizontalDistanceToText&&i.detail.horizontalDistanceToTextt.priority-e.priority)),t}_onMouseLeave(e){const t=this._editor.getDomNode();(!t||!(0,c.U)(t,e.x,e.y))&&this.hide()}startShowingAtRange(e,t,i,s){this._startShowingOrUpdateHover(new g.hx(0,e,void 0,void 0),t,i,s,null)}async updateHoverVerbosityLevel(e,t,i){this._renderedContentHover?.updateHoverVerbosityLevel(e,t,i)}focusedHoverPartIndex(){return this._renderedContentHover?.focusedHoverPartIndex??-1}containsNode(e){return!!e&&this._contentHoverWidget.getDomNode().contains(e)}focus(){this._contentHoverWidget.focus()}scrollUp(){this._contentHoverWidget.scrollUp()}scrollDown(){this._contentHoverWidget.scrollDown()}scrollLeft(){this._contentHoverWidget.scrollLeft()}scrollRight(){this._contentHoverWidget.scrollRight()}pageUp(){this._contentHoverWidget.pageUp()}pageDown(){this._contentHoverWidget.pageDown()}goToTop(){this._contentHoverWidget.goToTop()}goToBottom(){this._contentHoverWidget.goToBottom()}hide(){this._computer.anchor=null,this._hoverOperation.cancel(),this._setCurrentResult(null)}getDomNode(){return this._contentHoverWidget.getDomNode()}get isColorPickerVisible(){return this._renderedContentHover?.isColorPickerVisible()??!1}get isVisibleFromKeyboard(){return this._contentHoverWidget.isVisibleFromKeyboard}get isVisible(){return this._contentHoverWidget.isVisible}get isFocused(){return this._contentHoverWidget.isFocused}get isResizing(){return this._contentHoverWidget.isResizing}get widget(){return this._contentHoverWidget}};G=V([z(1,r._Y),z(2,a.b)],G);i(82320);var j,K=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Y=function(e,t){return function(i,s){t(i,s,e)}};let q=class extends n.jG{static{j=this}static{this.ID="editor.contrib.contentHover"}constructor(e,t,i){super(),this._editor=e,this._instantiationService=t,this._keybindingService=i,this._onHoverContentsChanged=this._register(new y.vl),this.shouldKeepOpenOnEditorMouseMoveOrLeave=!1,this._listenersStore=new n.Cm,this._hoverState={mouseDown:!1,activatedByDecoratorClick:!1},this._reactToEditorMouseMoveRunner=this._register(new l.uC((()=>this._reactToEditorMouseMove(this._mouseMoveEvent)),0)),this._hookListeners(),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(60)&&(this._unhookListeners(),this._hookListeners())})))}static get(e){return e.getContribution(j.ID)}_hookListeners(){const e=this._editor.getOption(60);this._hoverSettings={enabled:e.enabled,sticky:e.sticky,hidingDelay:e.hidingDelay},e.enabled?(this._listenersStore.add(this._editor.onMouseDown((e=>this._onEditorMouseDown(e)))),this._listenersStore.add(this._editor.onMouseUp((()=>this._onEditorMouseUp()))),this._listenersStore.add(this._editor.onMouseMove((e=>this._onEditorMouseMove(e)))),this._listenersStore.add(this._editor.onKeyDown((e=>this._onKeyDown(e))))):(this._listenersStore.add(this._editor.onMouseMove((e=>this._onEditorMouseMove(e)))),this._listenersStore.add(this._editor.onKeyDown((e=>this._onKeyDown(e))))),this._listenersStore.add(this._editor.onMouseLeave((e=>this._onEditorMouseLeave(e)))),this._listenersStore.add(this._editor.onDidChangeModel((()=>{this._cancelScheduler(),this._hideWidgets()}))),this._listenersStore.add(this._editor.onDidChangeModelContent((()=>this._cancelScheduler()))),this._listenersStore.add(this._editor.onDidScrollChange((e=>this._onEditorScrollChanged(e))))}_unhookListeners(){this._listenersStore.clear()}_cancelScheduler(){this._mouseMoveEvent=void 0,this._reactToEditorMouseMoveRunner.cancel()}_onEditorScrollChanged(e){(e.scrollTopChanged||e.scrollLeftChanged)&&this._hideWidgets()}_onEditorMouseDown(e){this._hoverState.mouseDown=!0;this._shouldNotHideCurrentHoverWidget(e)||this._hideWidgets()}_shouldNotHideCurrentHoverWidget(e){return this._isMouseOnContentHoverWidget(e)||this._isContentWidgetResizing()}_isMouseOnContentHoverWidget(e){const t=this._contentWidget?.getDomNode();return!!t&&(0,c.U)(t,e.event.posx,e.event.posy)}_onEditorMouseUp(){this._hoverState.mouseDown=!1}_onEditorMouseLeave(e){if(this.shouldKeepOpenOnEditorMouseMoveOrLeave)return;this._cancelScheduler();this._shouldNotHideCurrentHoverWidget(e)||this._hideWidgets()}_shouldNotRecomputeCurrentHoverWidget(e){const t=this._hoverSettings.sticky;return((e,t)=>{const i=this._isMouseOnContentHoverWidget(e);return t&&i})(e,t)||(e=>{const t=this._isMouseOnContentHoverWidget(e),i=this._contentWidget?.isColorPickerVisible??!1;return t&&i})(e)||((e,t)=>(t&&this._contentWidget?.containsNode(e.event.browserEvent.view?.document.activeElement)&&!e.event.browserEvent.view?.getSelection()?.isCollapsed)??!1)(e,t)}_onEditorMouseMove(e){if(this.shouldKeepOpenOnEditorMouseMoveOrLeave)return;if(this._mouseMoveEvent=e,this._contentWidget?.isFocused||this._contentWidget?.isResizing)return;const t=this._hoverSettings.sticky;if(t&&this._contentWidget?.isVisibleFromKeyboard)return;if(this._shouldNotRecomputeCurrentHoverWidget(e))return void this._reactToEditorMouseMoveRunner.cancel();const i=this._hoverSettings.hidingDelay,s=this._contentWidget?.isVisible;s&&t&&i>0?this._reactToEditorMouseMoveRunner.isScheduled()||this._reactToEditorMouseMoveRunner.schedule(i):this._reactToEditorMouseMove(e)}_reactToEditorMouseMove(e){if(!e)return;const t=e.target,i=t.element?.classList.contains("colorpicker-color-decoration"),s=this._editor.getOption(149),n=this._hoverSettings.enabled,r=this._hoverState.activatedByDecoratorClick;if(i&&("click"===s&&!r||"hover"===s&&!n||"clickAndHover"===s&&!n&&!r)||!i&&!n&&!r)return void this._hideWidgets();this._tryShowHoverWidget(e)||this._hideWidgets()}_tryShowHoverWidget(e){return this._getOrCreateContentWidget().showsOrWillShow(e)}_onKeyDown(e){if(!this._editor.hasModel())return;const t=this._keybindingService.softDispatch(e,this._editor.getDomNode()),i=1===t.kind||2===t.kind&&(t.commandId===s.jA||t.commandId===s.jq||t.commandId===s.Zp)&&this._contentWidget?.isVisible;5===e.keyCode||6===e.keyCode||57===e.keyCode||4===e.keyCode||i||this._hideWidgets()}_hideWidgets(){this._hoverState.mouseDown&&this._contentWidget?.isColorPickerVisible||o.bo.dropDownVisible||(this._hoverState.activatedByDecoratorClick=!1,this._contentWidget?.hide())}_getOrCreateContentWidget(){return this._contentWidget||(this._contentWidget=this._instantiationService.createInstance(G,this._editor),this._listenersStore.add(this._contentWidget.onContentsChanged((()=>this._onHoverContentsChanged.fire())))),this._contentWidget}showContentHover(e,t,i,s,n=!1){this._hoverState.activatedByDecoratorClick=n,this._getOrCreateContentWidget().startShowingAtRange(e,t,i,s)}_isContentWidgetResizing(){return this._contentWidget?.widget.isResizing||!1}focusedHoverPartIndex(){return this._getOrCreateContentWidget().focusedHoverPartIndex()}updateHoverVerbosityLevel(e,t,i){this._getOrCreateContentWidget().updateHoverVerbosityLevel(e,t,i)}focus(){this._contentWidget?.focus()}scrollUp(){this._contentWidget?.scrollUp()}scrollDown(){this._contentWidget?.scrollDown()}scrollLeft(){this._contentWidget?.scrollLeft()}scrollRight(){this._contentWidget?.scrollRight()}pageUp(){this._contentWidget?.pageUp()}pageDown(){this._contentWidget?.pageDown()}goToTop(){this._contentWidget?.goToTop()}goToBottom(){this._contentWidget?.goToBottom()}get isColorPickerVisible(){return this._contentWidget?.isColorPickerVisible}get isHoverVisible(){return this._contentWidget?.isVisible}dispose(){super.dispose(),this._unhookListeners(),this._listenersStore.dispose(),this._contentWidget?.dispose()}};q=j=K([Y(1,r._Y),Y(2,a.b)],q)},9270:(e,t,i)=>{"use strict";i.d(t,{L:()=>h});var s=i(8597),n=i(52776),r=i(5662),o=i(98031),a=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},l=function(e,t){return function(i,s){t(i,s,e)}};const c=s.$;let h=class extends r.jG{get hasContent(){return this._hasContent}constructor(e){super(),this._keybindingService=e,this.actions=[],this._hasContent=!1,this.hoverElement=c("div.hover-row.status-bar"),this.hoverElement.tabIndex=0,this.actionsElement=s.BC(this.hoverElement,c("div.actions"))}addAction(e){const t=this._keybindingService.lookupKeybinding(e.commandId),i=t?t.getLabel():null;this._hasContent=!0;const s=this._register(n.jQ.render(this.actionsElement,e,i));return this.actions.push(s),s}append(e){const t=s.BC(this.actionsElement,e);return this._hasContent=!0,t}};h=a([l(0,o.b)],h)},7142:(e,t,i)=>{"use strict";i.d(t,{U:()=>c});var s=i(90766),n=i(18447),r=i(64383),o=i(31450),a=i(56942);class l{constructor(e,t,i){this.provider=e,this.hover=t,this.ordinal=i}}function c(e,t,i,n,o=!1){const a=e.ordered(t,o).map(((e,s)=>async function(e,t,i,s,n){const o=await Promise.resolve(e.provideHover(i,s,n)).catch(r.M_);if(o&&function(e){const t="undefined"!==typeof e.range,i="undefined"!==typeof e.contents&&e.contents&&e.contents.length>0;return t&&i}(o))return new l(e,o,t)}(e,s,t,i,n)));return s.AE.fromPromises(a).coalesce()}function h(e,t,i,s,n=!1){return c(e,t,i,s,n).map((e=>e.hover)).toPromise()}(0,o.ke)("_executeHoverProvider",((e,t,i)=>h(e.get(a.ILanguageFeaturesService).hoverProvider,t,i,n.XO.None))),(0,o.ke)("_executeHoverProvider_recursive",((e,t,i)=>h(e.get(a.ILanguageFeaturesService).hoverProvider,t,i,n.XO.None,!0)))},87758:(e,t,i)=>{"use strict";i.d(t,{G8:()=>_,Hm:()=>d,Hp:()=>a,K6:()=>o,MB:()=>l,Xp:()=>u,Zp:()=>f,dV:()=>r,iM:()=>m,ih:()=>h,jA:()=>n,jq:()=>p,vf:()=>c,vx:()=>g});var s=i(78209);const n="editor.action.showHover",r="editor.action.showDefinitionPreviewHover",o="editor.action.scrollUpHover",a="editor.action.scrollDownHover",l="editor.action.scrollLeftHover",c="editor.action.scrollRightHover",h="editor.action.pageUpHover",d="editor.action.pageDownHover",u="editor.action.goToTopHover",g="editor.action.goToBottomHover",p="editor.action.increaseHoverVerbosityLevel",m=s.kg({key:"increaseHoverVerbosityLevel",comment:["Label for action that will increase the hover verbosity level."]},"Increase Hover Verbosity Level"),f="editor.action.decreaseHoverVerbosityLevel",_=s.kg({key:"decreaseHoverVerbosityLevel",comment:["Label for action that will decrease the hover verbosity level."]},"Decrease Hover Verbosity Level")},58466:(e,t,i)=>{"use strict";var s,n=i(87758),r=i(24939),o=i(31450),a=i(36677),l=i(60002),c=i(62427),h=i(77011),d=i(62083),u=i(78209);i(82320);!function(e){e.NoAutoFocus="noAutoFocus",e.FocusIfVisible="focusIfVisible",e.AutoFocusImmediately="autoFocusImmediately"}(s||(s={}));class g extends o.ks{constructor(){super({id:n.jA,label:u.kg({key:"showOrFocusHover",comment:["Label for action that will trigger the showing/focusing of a hover in the editor.","If the hover is not visible, it will show the hover.","This allows for users to show the hover without using the mouse."]},"Show or Focus Hover"),metadata:{description:u.aS("showOrFocusHoverDescription","Show or focus the editor hover which shows documentation, references, and other content for a symbol at the current cursor position."),args:[{name:"args",schema:{type:"object",properties:{focus:{description:"Controls if and when the hover should take focus upon being triggered by this action.",enum:[s.NoAutoFocus,s.FocusIfVisible,s.AutoFocusImmediately],enumDescriptions:[u.kg("showOrFocusHover.focus.noAutoFocus","The hover will not automatically take focus."),u.kg("showOrFocusHover.focus.focusIfVisible","The hover will take focus only if it is already visible."),u.kg("showOrFocusHover.focus.autoFocusImmediately","The hover will automatically take focus when it appears.")],default:s.FocusIfVisible}}}}]},alias:"Show or Focus Hover",precondition:void 0,kbOpts:{kbExpr:l.R.editorTextFocus,primary:(0,r.m5)(2089,2087),weight:100}})}run(e,t,i){if(!t.hasModel())return;const n=h.A.get(t);if(!n)return;const r=i?.focus;let o=s.FocusIfVisible;Object.values(s).includes(r)?o=r:"boolean"===typeof r&&r&&(o=s.AutoFocusImmediately);const l=e=>{const i=t.getPosition(),s=new a.Q(i.lineNumber,i.column,i.lineNumber,i.column);n.showContentHover(s,1,1,e)},c=2===t.getOption(2);n.isHoverVisible?o!==s.NoAutoFocus?n.focus():l(c):l(c||o===s.AutoFocusImmediately)}}class p extends o.ks{constructor(){super({id:n.dV,label:u.kg({key:"showDefinitionPreviewHover",comment:["Label for action that will trigger the showing of definition preview hover in the editor.","This allows for users to show the definition preview hover without using the mouse."]},"Show Definition Preview Hover"),alias:"Show Definition Preview Hover",precondition:void 0,metadata:{description:u.aS("showDefinitionPreviewHoverDescription","Show the definition preview hover in the editor.")}})}run(e,t){const i=h.A.get(t);if(!i)return;const s=t.getPosition();if(!s)return;const n=new a.Q(s.lineNumber,s.column,s.lineNumber,s.column),r=c.k.get(t);if(!r)return;r.startFindDefinitionFromCursor(s).then((()=>{i.showContentHover(n,1,1,!0)}))}}class m extends o.ks{constructor(){super({id:n.K6,label:u.kg({key:"scrollUpHover",comment:["Action that allows to scroll up in the hover widget with the up arrow when the hover widget is focused."]},"Scroll Up Hover"),alias:"Scroll Up Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:16,weight:100},metadata:{description:u.aS("scrollUpHoverDescription","Scroll up the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.scrollUp()}}class f extends o.ks{constructor(){super({id:n.Hp,label:u.kg({key:"scrollDownHover",comment:["Action that allows to scroll down in the hover widget with the up arrow when the hover widget is focused."]},"Scroll Down Hover"),alias:"Scroll Down Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:18,weight:100},metadata:{description:u.aS("scrollDownHoverDescription","Scroll down the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.scrollDown()}}class _ extends o.ks{constructor(){super({id:n.MB,label:u.kg({key:"scrollLeftHover",comment:["Action that allows to scroll left in the hover widget with the left arrow when the hover widget is focused."]},"Scroll Left Hover"),alias:"Scroll Left Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:15,weight:100},metadata:{description:u.aS("scrollLeftHoverDescription","Scroll left the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.scrollLeft()}}class v extends o.ks{constructor(){super({id:n.vf,label:u.kg({key:"scrollRightHover",comment:["Action that allows to scroll right in the hover widget with the right arrow when the hover widget is focused."]},"Scroll Right Hover"),alias:"Scroll Right Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:17,weight:100},metadata:{description:u.aS("scrollRightHoverDescription","Scroll right the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.scrollRight()}}class C extends o.ks{constructor(){super({id:n.ih,label:u.kg({key:"pageUpHover",comment:["Action that allows to page up in the hover widget with the page up command when the hover widget is focused."]},"Page Up Hover"),alias:"Page Up Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:11,secondary:[528],weight:100},metadata:{description:u.aS("pageUpHoverDescription","Page up the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.pageUp()}}class b extends o.ks{constructor(){super({id:n.Hm,label:u.kg({key:"pageDownHover",comment:["Action that allows to page down in the hover widget with the page down command when the hover widget is focused."]},"Page Down Hover"),alias:"Page Down Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:12,secondary:[530],weight:100},metadata:{description:u.aS("pageDownHoverDescription","Page down the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.pageDown()}}class E extends o.ks{constructor(){super({id:n.Xp,label:u.kg({key:"goToTopHover",comment:["Action that allows to go to the top of the hover widget with the home command when the hover widget is focused."]},"Go To Top Hover"),alias:"Go To Bottom Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:14,secondary:[2064],weight:100},metadata:{description:u.aS("goToTopHoverDescription","Go to the top of the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.goToTop()}}class S extends o.ks{constructor(){super({id:n.vx,label:u.kg({key:"goToBottomHover",comment:["Action that allows to go to the bottom in the hover widget with the end command when the hover widget is focused."]},"Go To Bottom Hover"),alias:"Go To Bottom Hover",precondition:l.R.hoverFocused,kbOpts:{kbExpr:l.R.hoverFocused,primary:13,secondary:[2066],weight:100},metadata:{description:u.aS("goToBottomHoverDescription","Go to the bottom of the editor hover.")}})}run(e,t){const i=h.A.get(t);i&&i.goToBottom()}}class y extends o.ks{constructor(){super({id:n.jq,label:n.iM,alias:"Increase Hover Verbosity Level",precondition:l.R.hoverVisible})}run(e,t,i){const s=h.A.get(t);if(!s)return;const n=void 0!==i?.index?i.index:s.focusedHoverPartIndex();s.updateHoverVerbosityLevel(d.M$.Increase,n,i?.focus)}}class w extends o.ks{constructor(){super({id:n.Zp,label:n.G8,alias:"Decrease Hover Verbosity Level",precondition:l.R.hoverVisible})}run(e,t,i){const s=h.A.get(t);if(!s)return;const n=void 0!==i?.index?i.index:s.focusedHoverPartIndex();h.A.get(t)?.updateHoverVerbosityLevel(d.M$.Decrease,n,i?.focus)}}var L=i(66261),R=i(47612),T=i(57039),x=i(57286),k=i(8597),A=i(25890),N=i(90766),I=i(64383),O=i(5662),D=i(89403),M=i(56942),P=i(37550),F=i(55130),U=i(71933),H=i(61407),B=i(65877),W=i(75147),V=i(49099),z=i(73823),G=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},j=function(e,t){return function(i,s){t(i,s,e)}};const K=k.$;class Y{constructor(e,t,i){this.owner=e,this.range=t,this.marker=i}isValidForHoverAnchor(e){return 1===e.type&&this.range.startColumn<=e.range.startColumn&&this.range.endColumn>=e.range.endColumn}}const q={type:1,filter:{include:H.gB.QuickFix},triggerAction:H.fo.QuickFixHover};let $=class{constructor(e,t,i,s){this._editor=e,this._markerDecorationsService=t,this._openerService=i,this._languageFeaturesService=s,this.hoverOrdinal=1,this.recentMarkerCodeActionsInfo=void 0}computeSync(e,t){if(!this._editor.hasModel()||1!==e.type&&!e.supportsMarkerHover)return[];const i=this._editor.getModel(),s=e.range.startLineNumber,n=i.getLineMaxColumn(s),r=[];for(const o of t){const t=o.range.startLineNumber===s?o.range.startColumn:1,l=o.range.endLineNumber===s?o.range.endColumn:n,c=this._markerDecorationsService.getMarker(i.uri,o);if(!c)continue;const h=new a.Q(e.range.startLineNumber,t,e.range.startLineNumber,l);r.push(new Y(this,h,c))}return r}renderHoverParts(e,t){if(!t.length)return new T.Ke([]);const i=new O.Cm,s=[];t.forEach((t=>{const i=this._renderMarkerHover(t);e.fragment.appendChild(i.hoverElement),s.push(i)}));const n=1===t.length?t[0]:t.sort(((e,t)=>W.cj.compare(e.marker.severity,t.marker.severity)))[0];return this.renderMarkerStatusbar(e,n,i),new T.Ke(s)}_renderMarkerHover(e){const t=new O.Cm,i=K("div.hover-row"),s=k.BC(i,K("div.marker.hover-contents")),{source:n,message:r,code:o,relatedInformation:a}=e.marker;this._editor.applyFontInfo(s);const l=k.BC(s,K("span"));if(l.style.whiteSpace="pre-wrap",l.innerText=r,n||o)if(o&&"string"!==typeof o){const e=K("span");if(n){k.BC(e,K("span")).innerText=n}const i=k.BC(e,K("a.code-link"));i.setAttribute("href",o.target.toString()),t.add(k.ko(i,"click",(e=>{this._openerService.open(o.target,{allowCommands:!0}),e.preventDefault(),e.stopPropagation()})));k.BC(i,K("span")).innerText=o.value;const r=k.BC(s,e);r.style.opacity="0.6",r.style.paddingLeft="6px"}else{const e=k.BC(s,K("span"));e.style.opacity="0.6",e.style.paddingLeft="6px",e.innerText=n&&o?`${n}(${o})`:n||`(${o})`}if((0,A.EI)(a))for(const{message:c,resource:h,startLineNumber:d,startColumn:u}of a){const e=k.BC(s,K("div"));e.style.marginTop="8px";const i=k.BC(e,K("a"));i.innerText=`${(0,D.P8)(h)}(${d}, ${u}): `,i.style.cursor="pointer",t.add(k.ko(i,"click",(e=>{if(e.stopPropagation(),e.preventDefault(),this._openerService){const e={selection:{startLineNumber:d,startColumn:u}};this._openerService.open(h,{fromUserGesture:!0,editorOptions:e}).catch(I.dz)}})));const n=k.BC(e,K("span"));n.innerText=c,this._editor.applyFontInfo(n)}return{hoverPart:e,hoverElement:i,dispose:()=>t.dispose()}}renderMarkerStatusbar(e,t,i){if(t.marker.severity===W.cj.Error||t.marker.severity===W.cj.Warning||t.marker.severity===W.cj.Info){const i=B.j.get(this._editor);i&&e.statusBar.addAction({label:u.kg("view problem","View Problem"),commandId:B.i.ID,run:()=>{e.hide(),i.showAtMarker(t.marker),this._editor.focus()}})}if(!this._editor.getOption(92)){const s=e.statusBar.append(K("div"));this.recentMarkerCodeActionsInfo&&(W.oc.makeKey(this.recentMarkerCodeActionsInfo.marker)===W.oc.makeKey(t.marker)?this.recentMarkerCodeActionsInfo.hasCodeActions||(s.textContent=u.kg("noQuickFixes","No quick fixes available")):this.recentMarkerCodeActionsInfo=void 0);const n=this.recentMarkerCodeActionsInfo&&!this.recentMarkerCodeActionsInfo.hasCodeActions?O.jG.None:(0,N.EQ)((()=>s.textContent=u.kg("checkingForQuickFixes","Checking for quick fixes...")),200,i);s.textContent||(s.textContent=String.fromCharCode(160));const r=this.getCodeActions(t.marker);i.add((0,O.s)((()=>r.cancel()))),r.then((r=>{if(n.dispose(),this.recentMarkerCodeActionsInfo={marker:t.marker,hasCodeActions:r.validActions.length>0},!this.recentMarkerCodeActionsInfo.hasCodeActions)return r.dispose(),void(s.textContent=u.kg("noQuickFixes","No quick fixes available"));s.style.display="none";let o=!1;i.add((0,O.s)((()=>{o||r.dispose()}))),e.statusBar.addAction({label:u.kg("quick fixes","Quick Fix..."),commandId:F.pQ,run:t=>{o=!0;const i=U.C.get(this._editor),s=k.BK(t);e.hide(),i?.showCodeActions(q,r,{x:s.left,y:s.top,width:s.width,height:s.height})}})}),I.dz)}}getCodeActions(e){return(0,N.SS)((t=>(0,F.dU)(this._languageFeaturesService.codeActionProvider,this._editor.getModel(),new a.Q(e.startLineNumber,e.startColumn,e.endLineNumber,e.endColumn),q,z.ke.None,t)))}};$=G([j(1,P.IMarkerDecorationsService),j(2,V.C),j(3,M.ILanguageFeaturesService)],$);var Q=i(63591),X=i(51219),Z=i(20492),J=i(10154),ee=i(12143),te=i(52776),ie=i(16980),se=i(16223);class ne{get lineNumber(){return this._lineNumber}set lineNumber(e){this._lineNumber=e}get lane(){return this._laneOrLine}set lane(e){this._laneOrLine=e}constructor(e){this._editor=e,this._lineNumber=-1,this._laneOrLine=se.ZS.Center}computeSync(){const e=e=>({value:e}),t=this._editor.getLineDecorations(this._lineNumber),i=[],s="lineNo"===this._laneOrLine;if(!t)return i;for(const n of t){const t=n.options.glyphMargin?.position??se.ZS.Center;if(!s&&t!==this._laneOrLine)continue;const r=s?n.options.lineNumberHoverMessage:n.options.glyphMarginHoverMessage;r&&!(0,ie.it)(r)&&i.push(...(0,A._j)(r).map(e))}return i}}var re,oe=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ae=function(e,t){return function(i,s){t(i,s,e)}};const le=k.$;let ce=class extends O.jG{static{re=this}static{this.ID="editor.contrib.modesGlyphHoverWidget"}constructor(e,t,i){super(),this._renderDisposeables=this._register(new O.Cm),this._editor=e,this._isVisible=!1,this._messages=[],this._hover=this._register(new te.N4),this._hover.containerDomNode.classList.toggle("hidden",!this._isVisible),this._markdownRenderer=this._register(new Z.T({editor:this._editor},t,i)),this._computer=new ne(this._editor),this._hoverOperation=this._register(new ee.w(this._editor,this._computer)),this._register(this._hoverOperation.onResult((e=>{this._withResult(e.value)}))),this._register(this._editor.onDidChangeModelDecorations((()=>this._onModelDecorationsChanged()))),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(50)&&this._updateFont()}))),this._register(k.b2(this._hover.containerDomNode,"mouseleave",(e=>{this._onMouseLeave(e)}))),this._editor.addOverlayWidget(this)}dispose(){this._editor.removeOverlayWidget(this),super.dispose()}getId(){return re.ID}getDomNode(){return this._hover.containerDomNode}getPosition(){return null}_updateFont(){Array.prototype.slice.call(this._hover.contentsDomNode.getElementsByClassName("code")).forEach((e=>this._editor.applyFontInfo(e)))}_onModelDecorationsChanged(){this._isVisible&&(this._hoverOperation.cancel(),this._hoverOperation.start(0))}showsOrWillShow(e){const t=e.target;return 2===t.type&&t.detail.glyphMarginLane?(this._startShowingAt(t.position.lineNumber,t.detail.glyphMarginLane),!0):3===t.type&&(this._startShowingAt(t.position.lineNumber,"lineNo"),!0)}_startShowingAt(e,t){this._computer.lineNumber===e&&this._computer.lane===t||(this._hoverOperation.cancel(),this.hide(),this._computer.lineNumber=e,this._computer.lane=t,this._hoverOperation.start(0))}hide(){this._computer.lineNumber=-1,this._hoverOperation.cancel(),this._isVisible&&(this._isVisible=!1,this._hover.containerDomNode.classList.toggle("hidden",!this._isVisible))}_withResult(e){this._messages=e,this._messages.length>0?this._renderMessages(this._computer.lineNumber,this._messages):this.hide()}_renderMessages(e,t){this._renderDisposeables.clear();const i=document.createDocumentFragment();for(const s of t){const e=le("div.hover-row.markdown-hover"),t=k.BC(e,le("div.hover-contents")),n=this._renderDisposeables.add(this._markdownRenderer.render(s.value));t.appendChild(n.element),i.appendChild(e)}this._updateContents(i),this._showAt(e)}_updateContents(e){this._hover.contentsDomNode.textContent="",this._hover.contentsDomNode.appendChild(e),this._updateFont()}_showAt(e){this._isVisible||(this._isVisible=!0,this._hover.containerDomNode.classList.toggle("hidden",!this._isVisible));const t=this._editor.getLayoutInfo(),i=this._editor.getTopForLineNumber(e),s=this._editor.getScrollTop(),n=this._editor.getOption(67),r=i-s-(this._hover.containerDomNode.clientHeight-n)/2,o=t.glyphMarginLeft+t.glyphMarginWidth+("lineNo"===this._computer.lane?t.lineNumbersWidth:0);this._hover.containerDomNode.style.left=`${o}px`,this._hover.containerDomNode.style.top=`${Math.max(Math.round(r),0)}px`}_onMouseLeave(e){const t=this._editor.getDomNode();(!t||!(0,X.U)(t,e.x,e.y))&&this.hide()}};ce=re=oe([ae(1,J.L),ae(2,V.C)],ce);var he=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},de=function(e,t){return function(i,s){t(i,s,e)}};let ue=class extends O.jG{static{this.ID="editor.contrib.marginHover"}constructor(e,t){super(),this._editor=e,this._instantiationService=t,this.shouldKeepOpenOnEditorMouseMoveOrLeave=!1,this._listenersStore=new O.Cm,this._hoverState={mouseDown:!1},this._reactToEditorMouseMoveRunner=this._register(new N.uC((()=>this._reactToEditorMouseMove(this._mouseMoveEvent)),0)),this._hookListeners(),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(60)&&(this._unhookListeners(),this._hookListeners())})))}_hookListeners(){const e=this._editor.getOption(60);this._hoverSettings={enabled:e.enabled,sticky:e.sticky,hidingDelay:e.hidingDelay},e.enabled?(this._listenersStore.add(this._editor.onMouseDown((e=>this._onEditorMouseDown(e)))),this._listenersStore.add(this._editor.onMouseUp((()=>this._onEditorMouseUp()))),this._listenersStore.add(this._editor.onMouseMove((e=>this._onEditorMouseMove(e)))),this._listenersStore.add(this._editor.onKeyDown((e=>this._onKeyDown(e))))):(this._listenersStore.add(this._editor.onMouseMove((e=>this._onEditorMouseMove(e)))),this._listenersStore.add(this._editor.onKeyDown((e=>this._onKeyDown(e))))),this._listenersStore.add(this._editor.onMouseLeave((e=>this._onEditorMouseLeave(e)))),this._listenersStore.add(this._editor.onDidChangeModel((()=>{this._cancelScheduler(),this._hideWidgets()}))),this._listenersStore.add(this._editor.onDidChangeModelContent((()=>this._cancelScheduler()))),this._listenersStore.add(this._editor.onDidScrollChange((e=>this._onEditorScrollChanged(e))))}_unhookListeners(){this._listenersStore.clear()}_cancelScheduler(){this._mouseMoveEvent=void 0,this._reactToEditorMouseMoveRunner.cancel()}_onEditorScrollChanged(e){(e.scrollTopChanged||e.scrollLeftChanged)&&this._hideWidgets()}_onEditorMouseDown(e){this._hoverState.mouseDown=!0;this._isMouseOnMarginHoverWidget(e)||this._hideWidgets()}_isMouseOnMarginHoverWidget(e){const t=this._glyphWidget?.getDomNode();return!!t&&(0,X.U)(t,e.event.posx,e.event.posy)}_onEditorMouseUp(){this._hoverState.mouseDown=!1}_onEditorMouseLeave(e){if(this.shouldKeepOpenOnEditorMouseMoveOrLeave)return;this._cancelScheduler();this._isMouseOnMarginHoverWidget(e)||this._hideWidgets()}_shouldNotRecomputeCurrentHoverWidget(e){const t=this._hoverSettings.sticky,i=this._isMouseOnMarginHoverWidget(e);return t&&i}_onEditorMouseMove(e){if(this.shouldKeepOpenOnEditorMouseMoveOrLeave)return;this._mouseMoveEvent=e;this._shouldNotRecomputeCurrentHoverWidget(e)?this._reactToEditorMouseMoveRunner.cancel():this._reactToEditorMouseMove(e)}_reactToEditorMouseMove(e){if(!e)return;this._tryShowHoverWidget(e)||this._hideWidgets()}_tryShowHoverWidget(e){return this._getOrCreateGlyphWidget().showsOrWillShow(e)}_onKeyDown(e){this._editor.hasModel()&&5!==e.keyCode&&6!==e.keyCode&&57!==e.keyCode&&4!==e.keyCode&&this._hideWidgets()}_hideWidgets(){this._glyphWidget?.hide()}_getOrCreateGlyphWidget(){return this._glyphWidget||(this._glyphWidget=this._instantiationService.createInstance(ce,this._editor)),this._glyphWidget}dispose(){super.dispose(),this._unhookListeners(),this._listenersStore.dispose(),this._glyphWidget?.dispose()}};ue=he([de(1,Q._Y)],ue);var ge=i(96282);(0,o.HW)(h.A.ID,h.A,2),(0,o.HW)(ue.ID,ue,2),(0,o.Fl)(g),(0,o.Fl)(p),(0,o.Fl)(m),(0,o.Fl)(f),(0,o.Fl)(_),(0,o.Fl)(v),(0,o.Fl)(C),(0,o.Fl)(b),(0,o.Fl)(E),(0,o.Fl)(S),(0,o.Fl)(y),(0,o.Fl)(w),T.B2.register(x.xJ),T.B2.register($),(0,R.zy)(((e,t)=>{const i=e.getColor(L.oZ8);i&&(t.addRule(`.monaco-editor .monaco-hover .hover-row:not(:first-child):not(:empty) { border-top: 1px solid ${i.transparent(.5)}; }`),t.addRule(`.monaco-editor .monaco-hover hr { border-top: 1px solid ${i.transparent(.5)}; }`),t.addRule(`.monaco-editor .monaco-hover hr { border-bottom: 0px solid ${i.transparent(.5)}; }`))})),ge.Z.register(new class{}),ge.Z.register(new class{}),ge.Z.register(new class{})},12143:(e,t,i)=>{"use strict";i.d(t,{w:()=>l});var s=i(90766),n=i(64383),r=i(41234),o=i(5662);class a{constructor(e,t,i){this.value=e,this.isComplete=t,this.hasLoadingMessage=i}}class l extends o.jG{constructor(e,t){super(),this._editor=e,this._computer=t,this._onResult=this._register(new r.vl),this.onResult=this._onResult.event,this._firstWaitScheduler=this._register(new s.uC((()=>this._triggerAsyncComputation()),0)),this._secondWaitScheduler=this._register(new s.uC((()=>this._triggerSyncComputation()),0)),this._loadingMessageScheduler=this._register(new s.uC((()=>this._triggerLoadingMessage()),0)),this._state=0,this._asyncIterable=null,this._asyncIterableDone=!1,this._result=[]}dispose(){this._asyncIterable&&(this._asyncIterable.cancel(),this._asyncIterable=null),super.dispose()}get _hoverTime(){return this._editor.getOption(60).delay}get _firstWaitTime(){return this._hoverTime/2}get _secondWaitTime(){return this._hoverTime-this._firstWaitTime}get _loadingMessageTime(){return 3*this._hoverTime}_setState(e,t=!0){this._state=e,t&&this._fireResult()}_triggerAsyncComputation(){this._setState(2),this._secondWaitScheduler.schedule(this._secondWaitTime),this._computer.computeAsync?(this._asyncIterableDone=!1,this._asyncIterable=(0,s.bI)((e=>this._computer.computeAsync(e))),(async()=>{try{for await(const e of this._asyncIterable)e&&(this._result.push(e),this._fireResult());this._asyncIterableDone=!0,3!==this._state&&4!==this._state||this._setState(0)}catch(e){(0,n.dz)(e)}})()):this._asyncIterableDone=!0}_triggerSyncComputation(){this._computer.computeSync&&(this._result=this._result.concat(this._computer.computeSync())),this._setState(this._asyncIterableDone?0:3)}_triggerLoadingMessage(){3===this._state&&this._setState(4)}_fireResult(){if(1===this._state||2===this._state)return;const e=0===this._state,t=4===this._state;this._onResult.fire(new a(this._result.slice(0),e,t))}start(e){if(0===e)0===this._state&&(this._setState(1),this._firstWaitScheduler.schedule(this._firstWaitTime),this._loadingMessageScheduler.schedule(this._loadingMessageTime));else switch(this._state){case 0:this._triggerAsyncComputation(),this._secondWaitScheduler.cancel(),this._triggerSyncComputation();break;case 2:this._secondWaitScheduler.cancel(),this._triggerSyncComputation()}}cancel(){this._firstWaitScheduler.cancel(),this._secondWaitScheduler.cancel(),this._loadingMessageScheduler.cancel(),this._asyncIterable&&(this._asyncIterable.cancel(),this._asyncIterable=null),this._result=[],this._setState(0,!1)}}},57039:(e,t,i)=>{"use strict";i.d(t,{B2:()=>o,Ke:()=>r,hx:()=>s,mm:()=>n});class s{constructor(e,t,i,s){this.priority=e,this.range=t,this.initialMousePosX=i,this.initialMousePosY=s,this.type=1}equals(e){return 1===e.type&&this.range.equalsRange(e.range)}canAdoptVisibleHover(e,t){return 1===e.type&&t.lineNumber===this.range.startLineNumber}}class n{constructor(e,t,i,s,n,r){this.priority=e,this.owner=t,this.range=i,this.initialMousePosX=s,this.initialMousePosY=n,this.supportsMarkerHover=r,this.type=2}equals(e){return 2===e.type&&this.owner===e.owner}canAdoptVisibleHover(e,t){return 2===e.type&&this.owner===e.owner}}class r{constructor(e){this.renderedHoverParts=e}dispose(){for(const e of this.renderedHoverParts)e.dispose()}}const o=new class{constructor(){this._participants=[]}register(e){this._participants.push(e)}getAll(){return this._participants}}},51219:(e,t,i)=>{"use strict";i.d(t,{U:()=>n});var s=i(8597);function n(e,t,i){const n=s.BK(e);return!(tn.left+n.width||in.top+n.height)}},57286:(e,t,i)=>{"use strict";i.d(t,{eH:()=>O,fm:()=>U,xJ:()=>M});var s=i(8597),n=i(25890),r=i(18447),o=i(16980),a=i(5662),l=i(20492),c=i(87758),h=i(36677),d=i(10154),u=i(57039),g=i(78209),p=i(84001),m=i(49099),f=i(56942),_=i(62083),v=i(61394),C=i(10350),b=i(25689),E=i(64383),S=i(98031),y=i(52776),w=i(67220),L=i(90766),R=i(7142),T=i(50091),x=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},k=function(e,t){return function(i,s){t(i,s,e)}};const A=s.$,N=(0,v.pU)("hover-increase-verbosity",C.W.add,g.kg("increaseHoverVerbosity","Icon for increaseing hover verbosity.")),I=(0,v.pU)("hover-decrease-verbosity",C.W.remove,g.kg("decreaseHoverVerbosity","Icon for decreasing hover verbosity."));class O{constructor(e,t,i,s,n,r=void 0){this.owner=e,this.range=t,this.contents=i,this.isBeforeContent=s,this.ordinal=n,this.source=r}isValidForHoverAnchor(e){return 1===e.type&&this.range.startColumn<=e.range.startColumn&&this.range.endColumn>=e.range.endColumn}}class D{constructor(e,t,i){this.hover=e,this.hoverProvider=t,this.hoverPosition=i}supportsVerbosityAction(e){switch(e){case _.M$.Increase:return this.hover.canIncreaseVerbosity??!1;case _.M$.Decrease:return this.hover.canDecreaseVerbosity??!1}}}let M=class{constructor(e,t,i,s,n,r,o,a){this._editor=e,this._languageService=t,this._openerService=i,this._configurationService=s,this._languageFeaturesService=n,this._keybindingService=r,this._hoverService=o,this._commandService=a,this.hoverOrdinal=3}createLoadingMessage(e){return new O(this,e.range,[(new o.Bc).appendText(g.kg("modesContentHover.loading","Loading..."))],!1,2e3)}computeSync(e,t){if(!this._editor.hasModel()||1!==e.type)return[];const i=this._editor.getModel(),s=e.range.startLineNumber,r=i.getLineMaxColumn(s),a=[];let l=1e3;const c=i.getLineLength(s),d=i.getLanguageIdAtPosition(e.range.startLineNumber,e.range.startColumn),u=this._editor.getOption(118),p=this._configurationService.getValue("editor.maxTokenizationLineLength",{overrideIdentifier:d});let m=!1;u>=0&&c>u&&e.range.startColumn>=u&&(m=!0,a.push(new O(this,e.range,[{value:g.kg("stopped rendering","Rendering paused for long line for performance reasons. This can be configured via `editor.stopRenderingLineAfter`.")}],!1,l++))),!m&&"number"===typeof p&&c>=p&&a.push(new O(this,e.range,[{value:g.kg("too many characters","Tokenization is skipped for long lines for performance reasons. This can be configured via `editor.maxTokenizationLineLength`.")}],!1,l++));let f=!1;for(const g of t){const t=g.range.startLineNumber===s?g.range.startColumn:1,i=g.range.endLineNumber===s?g.range.endColumn:r,c=g.options.hoverMessage;if(!c||(0,o.it)(c))continue;g.options.beforeContentClassName&&(f=!0);const d=new h.Q(e.range.startLineNumber,t,e.range.startLineNumber,i);a.push(new O(this,d,(0,n._j)(c),f,l++))}return a}computeAsync(e,t,i){if(!this._editor.hasModel()||1!==e.type)return L.AE.EMPTY;const s=this._editor.getModel(),n=this._languageFeaturesService.hoverProvider;if(!n.has(s))return L.AE.EMPTY;return this._getMarkdownHovers(n,s,e,i)}_getMarkdownHovers(e,t,i,s){const n=i.range.getStartPosition();return(0,R.U)(e,t,n,s).filter((e=>!(0,o.it)(e.hover.contents))).map((e=>{const t=e.hover.range?h.Q.lift(e.hover.range):i.range,s=new D(e.hover,e.provider,n);return new O(this,t,e.hover.contents,!1,e.ordinal,s)}))}renderHoverParts(e,t){return this._renderedHoverParts=new F(t,e.fragment,this,this._editor,this._languageService,this._openerService,this._commandService,this._keybindingService,this._hoverService,this._configurationService,e.onContentsChanged),this._renderedHoverParts}updateMarkdownHoverVerbosityLevel(e,t,i){return Promise.resolve(this._renderedHoverParts?.updateMarkdownHoverPartVerbosityLevel(e,t,i))}};M=x([k(1,d.L),k(2,m.C),k(3,p.pG),k(4,f.ILanguageFeaturesService),k(5,S.b),k(6,w.TN),k(7,T.d)],M);class P{constructor(e,t,i){this.hoverPart=e,this.hoverElement=t,this.disposables=i}dispose(){this.disposables.dispose()}}class F{constructor(e,t,i,s,n,r,o,l,c,h,d){this._hoverParticipant=i,this._editor=s,this._languageService=n,this._openerService=r,this._commandService=o,this._keybindingService=l,this._hoverService=c,this._configurationService=h,this._onFinishedRendering=d,this._ongoingHoverOperations=new Map,this._disposables=new a.Cm,this.renderedHoverParts=this._renderHoverParts(e,t,this._onFinishedRendering),this._disposables.add((0,a.s)((()=>{this.renderedHoverParts.forEach((e=>{e.dispose()})),this._ongoingHoverOperations.forEach((e=>{e.tokenSource.dispose(!0)}))})))}_renderHoverParts(e,t,i){return e.sort((0,n.VE)((e=>e.ordinal),n.U9)),e.map((e=>{const s=this._renderHoverPart(e,i);return t.appendChild(s.hoverElement),s}))}_renderHoverPart(e,t){const i=this._renderMarkdownHover(e,t),s=i.hoverElement,n=e.source,r=new a.Cm;if(r.add(i),!n)return new P(e,s,r);const o=n.supportsVerbosityAction(_.M$.Increase),l=n.supportsVerbosityAction(_.M$.Decrease);if(!o&&!l)return new P(e,s,r);const c=A("div.verbosity-actions");return s.prepend(c),r.add(this._renderHoverExpansionAction(c,_.M$.Increase,o)),r.add(this._renderHoverExpansionAction(c,_.M$.Decrease,l)),new P(e,s,r)}_renderMarkdownHover(e,t){return H(this._editor,e,this._languageService,this._openerService,t)}_renderHoverExpansionAction(e,t,i){const n=new a.Cm,r=t===_.M$.Increase,o=s.BC(e,A(b.L.asCSSSelector(r?N:I)));o.tabIndex=0;const l=new w.fO("mouse",!1,{target:e,position:{hoverPosition:0}},this._configurationService,this._hoverService);if(n.add(this._hoverService.setupManagedHover(l,o,function(e,t){switch(t){case _.M$.Increase:{const t=e.lookupKeybinding(c.jq);return t?g.kg("increaseVerbosityWithKb","Increase Hover Verbosity ({0})",t.getLabel()):g.kg("increaseVerbosity","Increase Hover Verbosity")}case _.M$.Decrease:{const t=e.lookupKeybinding(c.Zp);return t?g.kg("decreaseVerbosityWithKb","Decrease Hover Verbosity ({0})",t.getLabel()):g.kg("decreaseVerbosity","Decrease Hover Verbosity")}}}(this._keybindingService,t))),!i)return o.classList.add("disabled"),n;o.classList.add("enabled");const h=()=>this._commandService.executeCommand(t===_.M$.Increase?c.jq:c.Zp);return n.add(new y.vV(o,h)),n.add(new y.M4(o,h,[3,10])),n}async updateMarkdownHoverPartVerbosityLevel(e,t,i=!0){const s=this._editor.getModel();if(!s)return;const n=this._getRenderedHoverPartAtIndex(t),r=n?.hoverPart.source;if(!n||!r?.supportsVerbosityAction(e))return;const o=await this._fetchHover(r,s,e);if(!o)return;const a=new D(o,r.hoverProvider,r.hoverPosition),l=n.hoverPart,c=new O(this._hoverParticipant,l.range,o.contents,l.isBeforeContent,l.ordinal,a),h=this._renderHoverPart(c,this._onFinishedRendering);return this._replaceRenderedHoverPartAtIndex(t,h,c),i&&this._focusOnHoverPartWithIndex(t),{hoverPart:c,hoverElement:h.hoverElement}}async _fetchHover(e,t,i){let s=i===_.M$.Increase?1:-1;const n=e.hoverProvider,o=this._ongoingHoverOperations.get(n);o&&(o.tokenSource.cancel(),s+=o.verbosityDelta);const a=new r.Qi;this._ongoingHoverOperations.set(n,{verbosityDelta:s,tokenSource:a});const l={verbosityRequest:{verbosityDelta:s,previousHover:e.hover}};let c;try{c=await Promise.resolve(n.provideHover(t,e.hoverPosition,a.token,l))}catch(h){(0,E.M_)(h)}return a.dispose(),this._ongoingHoverOperations.delete(n),c}_replaceRenderedHoverPartAtIndex(e,t,i){if(e>=this.renderedHoverParts.length||e<0)return;const s=this.renderedHoverParts[e],n=s.hoverElement,r=t.hoverElement,o=Array.from(r.children);n.replaceChildren(...o);const a=new P(i,n,t.disposables);n.focus(),s.dispose(),this.renderedHoverParts[e]=a}_focusOnHoverPartWithIndex(e){this.renderedHoverParts[e].hoverElement.focus()}_getRenderedHoverPartAtIndex(e){return this.renderedHoverParts[e]}dispose(){this._disposables.dispose()}}function U(e,t,i,s,r){t.sort((0,n.VE)((e=>e.ordinal),n.U9));const o=[];for(const n of t)o.push(H(i,n,s,r,e.onContentsChanged));return new u.Ke(o)}function H(e,t,i,n,r){const c=new a.Cm,h=A("div.hover-row"),d=A("div.hover-row-contents");h.appendChild(d);const u=t.contents;for(const a of u){if((0,o.it)(a))continue;const t=A("div.markdown-hover"),h=s.BC(t,A("div.hover-contents")),u=c.add(new l.T({editor:e},i,n));c.add(u.onDidRenderAsync((()=>{h.className="hover-contents code-hover-contents",r()})));const g=c.add(u.render(a));h.appendChild(g.element),d.appendChild(t)}return{hoverPart:t,hoverElement:h,dispose(){c.dispose()}}}},28449:(e,t,i)=>{"use strict";var s=i(90766),n=i(64383),r=i(50868),o=i(31450),a=i(36677),l=i(75326),c=i(60002),h=i(87289),d=i(10920),u=i(78209);class g{constructor(e,t,i){this._editRange=e,this._originalSelection=t,this._text=i}getEditOperations(e,t){t.addTrackedEditOperation(this._editRange,this._text)}computeCursorState(e,t){const i=t.getInverseEditOperations()[0].range;return this._originalSelection.isEmpty()?new l.L(i.endLineNumber,Math.min(this._originalSelection.positionColumn,i.endColumn),i.endLineNumber,Math.min(this._originalSelection.positionColumn,i.endColumn)):new l.L(i.endLineNumber,i.endColumn-this._text.length,i.endLineNumber,i.endColumn)}}var p,m=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},f=function(e,t){return function(i,s){t(i,s,e)}};let _=class{static{p=this}static{this.ID="editor.contrib.inPlaceReplaceController"}static get(e){return e.getContribution(p.ID)}static{this.DECORATION=h.kI.register({description:"in-place-replace",className:"valueSetReplacement"})}constructor(e,t){this.editor=e,this.editorWorkerService=t,this.decorations=this.editor.createDecorationsCollection()}dispose(){}run(e,t){this.currentRequest?.cancel();const i=this.editor.getSelection(),o=this.editor.getModel();if(!o||!i)return;let c=i;if(c.startLineNumber!==c.endLineNumber)return;const h=new r.$t(this.editor,5),d=o.uri;return this.editorWorkerService.canNavigateValueSet(d)?(this.currentRequest=(0,s.SS)((e=>this.editorWorkerService.navigateValueSet(d,c,t))),this.currentRequest.then((t=>{if(!t||!t.range||!t.value)return;if(!h.validate(this.editor))return;const i=a.Q.lift(t.range);let r=t.range;const o=t.value.length-(c.endColumn-c.startColumn);r={startLineNumber:r.startLineNumber,startColumn:r.startColumn,endLineNumber:r.endLineNumber,endColumn:r.startColumn+t.value.length},o>1&&(c=new l.L(c.startLineNumber,c.startColumn,c.endLineNumber,c.endColumn+o-1));const d=new g(i,c,t.value);this.editor.pushUndoStop(),this.editor.executeCommand(e,d),this.editor.pushUndoStop(),this.decorations.set([{range:r,options:p.DECORATION}]),this.decorationRemover?.cancel(),this.decorationRemover=(0,s.wR)(350),this.decorationRemover.then((()=>this.decorations.clear())).catch(n.dz)})).catch(n.dz)):Promise.resolve(void 0)}};_=p=m([f(1,d.IEditorWorkerService)],_);class v extends o.ks{constructor(){super({id:"editor.action.inPlaceReplace.up",label:u.kg("InPlaceReplaceAction.previous.label","Replace with Previous Value"),alias:"Replace with Previous Value",precondition:c.R.writable,kbOpts:{kbExpr:c.R.editorTextFocus,primary:3159,weight:100}})}run(e,t){const i=_.get(t);return i?i.run(this.id,!1):Promise.resolve(void 0)}}class C extends o.ks{constructor(){super({id:"editor.action.inPlaceReplace.down",label:u.kg("InPlaceReplaceAction.next.label","Replace with Next Value"),alias:"Replace with Next Value",precondition:c.R.writable,kbOpts:{kbExpr:c.R.editorTextFocus,primary:3161,weight:100}})}run(e,t){const i=_.get(t);return i?i.run(this.id,!0):Promise.resolve(void 0)}}(0,o.HW)(_.ID,_,4),(0,o.Fl)(v),(0,o.Fl)(C)},57244:(e,t,i)=>{"use strict";var s=i(5662),n=i(91508),r=i(31450),o=i(7936),a=i(36677),l=i(60002),c=i(17469),h=i(23750),d=i(64395),u=i(78209),g=i(51467),p=i(82365),m=i(7085),f=i(93895),_=i(75326),v=i(27760);function C(e,t,i,s){if(1===e.getLineCount()&&1===e.getLineMaxColumn(1))return[];const r=t.getLanguageConfiguration(e.getLanguageId()).indentRulesSupport;if(!r)return[];const a=new v.no(e,r,t);for(s=Math.min(s,e.getLineCount());i<=s&&a.shouldIgnore(i);)i++;if(i>s-1)return[];const{tabSize:l,indentSize:c,insertSpaces:h}=e.getOptions(),d=(e,t)=>(t=t||1,o.Y.shiftIndent(e,e.length+t,l,c,h)),u=(e,t)=>(t=t||1,o.Y.unshiftIndent(e,e.length+t,l,c,h)),g=[],p=e.getLineContent(i);let C=n.UU(p),E=C;a.shouldIncrease(i)?(E=d(E),C=d(C)):a.shouldIndentNextLine(i)&&(E=d(E));for(let o=++i;o<=s;o++){if(b(e,o))continue;const t=e.getLineContent(o),i=n.UU(t),s=E;a.shouldDecrease(o,s)&&(E=u(E),C=u(C)),i!==E&&g.push(m.k.replaceMove(new _.L(o,1,o,i.length+1),(0,f.P)(E,c,h))),a.shouldIgnore(o)||(a.shouldIncrease(o,s)?(C=d(C),E=C):E=a.shouldIndentNextLine(o,s)?d(E):C)}return g}function b(e,t){if(!e.tokenization.isCheapToTokenize(t))return!1;return 2===e.tokenization.getLineTokens(t).getStandardTokenType(0)}var E=i(87469),S=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},y=function(e,t){return function(i,s){t(i,s,e)}};class w extends r.ks{static{this.ID="editor.action.indentationToSpaces"}constructor(){super({id:w.ID,label:u.kg("indentationToSpaces","Convert Indentation to Spaces"),alias:"Convert Indentation to Spaces",precondition:l.R.writable,metadata:{description:u.aS("indentationToSpacesDescription","Convert the tab indentation to spaces.")}})}run(e,t){const i=t.getModel();if(!i)return;const s=i.getOptions(),n=t.getSelection();if(!n)return;const r=new P(n,s.tabSize);t.pushUndoStop(),t.executeCommands(this.id,[r]),t.pushUndoStop(),i.updateOptions({insertSpaces:!0})}}class L extends r.ks{static{this.ID="editor.action.indentationToTabs"}constructor(){super({id:L.ID,label:u.kg("indentationToTabs","Convert Indentation to Tabs"),alias:"Convert Indentation to Tabs",precondition:l.R.writable,metadata:{description:u.aS("indentationToTabsDescription","Convert the spaces indentation to tabs.")}})}run(e,t){const i=t.getModel();if(!i)return;const s=i.getOptions(),n=t.getSelection();if(!n)return;const r=new F(n,s.tabSize);t.pushUndoStop(),t.executeCommands(this.id,[r]),t.pushUndoStop(),i.updateOptions({insertSpaces:!1})}}class R extends r.ks{constructor(e,t,i){super(i),this.insertSpaces=e,this.displaySizeOnly=t}run(e,t){const i=e.get(g.GK),s=e.get(h.IModelService),n=t.getModel();if(!n)return;const r=s.getCreationOptions(n.getLanguageId(),n.uri,n.isForSimpleWidget),o=n.getOptions(),a=[1,2,3,4,5,6,7,8].map((e=>({id:e.toString(),label:e.toString(),description:e===r.tabSize&&e===o.tabSize?u.kg("configuredTabSize","Configured Tab Size"):e===r.tabSize?u.kg("defaultTabSize","Default Tab Size"):e===o.tabSize?u.kg("currentTabSize","Current Tab Size"):void 0}))),l=Math.min(n.getOptions().tabSize-1,7);setTimeout((()=>{i.pick(a,{placeHolder:u.kg({key:"selectTabWidth",comment:["Tab corresponds to the tab key"]},"Select Tab Size for Current File"),activeItem:a[l]}).then((e=>{if(e&&n&&!n.isDisposed()){const t=parseInt(e.label,10);this.displaySizeOnly?n.updateOptions({tabSize:t}):n.updateOptions({tabSize:t,indentSize:t,insertSpaces:this.insertSpaces})}}))}),50)}}class T extends R{static{this.ID="editor.action.indentUsingTabs"}constructor(){super(!1,!1,{id:T.ID,label:u.kg("indentUsingTabs","Indent Using Tabs"),alias:"Indent Using Tabs",precondition:void 0,metadata:{description:u.aS("indentUsingTabsDescription","Use indentation with tabs.")}})}}class x extends R{static{this.ID="editor.action.indentUsingSpaces"}constructor(){super(!0,!1,{id:x.ID,label:u.kg("indentUsingSpaces","Indent Using Spaces"),alias:"Indent Using Spaces",precondition:void 0,metadata:{description:u.aS("indentUsingSpacesDescription","Use indentation with spaces.")}})}}class k extends R{static{this.ID="editor.action.changeTabDisplaySize"}constructor(){super(!0,!0,{id:k.ID,label:u.kg("changeTabDisplaySize","Change Tab Display Size"),alias:"Change Tab Display Size",precondition:void 0,metadata:{description:u.aS("changeTabDisplaySizeDescription","Change the space size equivalent of the tab.")}})}}class A extends r.ks{static{this.ID="editor.action.detectIndentation"}constructor(){super({id:A.ID,label:u.kg("detectIndentation","Detect Indentation from Content"),alias:"Detect Indentation from Content",precondition:void 0,metadata:{description:u.aS("detectIndentationDescription","Detect the indentation from content.")}})}run(e,t){const i=e.get(h.IModelService),s=t.getModel();if(!s)return;const n=i.getCreationOptions(s.getLanguageId(),s.uri,s.isForSimpleWidget);s.detectIndentation(n.insertSpaces,n.tabSize)}}class N extends r.ks{constructor(){super({id:"editor.action.reindentlines",label:u.kg("editor.reindentlines","Reindent Lines"),alias:"Reindent Lines",precondition:l.R.writable,metadata:{description:u.aS("editor.reindentlinesDescription","Reindent the lines of the editor.")}})}run(e,t){const i=e.get(c.JZ),s=t.getModel();if(!s)return;const n=C(s,i,1,s.getLineCount());n.length>0&&(t.pushUndoStop(),t.executeEdits(this.id,n),t.pushUndoStop())}}class I extends r.ks{constructor(){super({id:"editor.action.reindentselectedlines",label:u.kg("editor.reindentselectedlines","Reindent Selected Lines"),alias:"Reindent Selected Lines",precondition:l.R.writable,metadata:{description:u.aS("editor.reindentselectedlinesDescription","Reindent the selected lines of the editor.")}})}run(e,t){const i=e.get(c.JZ),s=t.getModel();if(!s)return;const n=t.getSelections();if(null===n)return;const r=[];for(const o of n){let e=o.startLineNumber,t=o.endLineNumber;if(e!==t&&1===o.endColumn&&t--,1===e){if(e===t)continue}else e--;const n=C(s,i,e,t);r.push(...n)}r.length>0&&(t.pushUndoStop(),t.executeEdits(this.id,r),t.pushUndoStop())}}class O{constructor(e,t){this._initialSelection=t,this._edits=[],this._selectionId=null;for(const i of e)i.range&&"string"===typeof i.text&&this._edits.push(i)}getEditOperations(e,t){for(const s of this._edits)t.addEditOperation(a.Q.lift(s.range),s.text);let i=!1;Array.isArray(this._edits)&&1===this._edits.length&&this._initialSelection.isEmpty()&&(this._edits[0].range.startColumn===this._initialSelection.endColumn&&this._edits[0].range.startLineNumber===this._initialSelection.endLineNumber?(i=!0,this._selectionId=t.trackSelection(this._initialSelection,!0)):this._edits[0].range.endColumn===this._initialSelection.startColumn&&this._edits[0].range.endLineNumber===this._initialSelection.startLineNumber&&(i=!0,this._selectionId=t.trackSelection(this._initialSelection,!1))),i||(this._selectionId=t.trackSelection(this._initialSelection))}computeCursorState(e,t){return t.getTrackedSelection(this._selectionId)}}let D=class{static{this.ID="editor.contrib.autoIndentOnPaste"}constructor(e,t){this.editor=e,this._languageConfigurationService=t,this.callOnDispose=new s.Cm,this.callOnModel=new s.Cm,this.callOnDispose.add(e.onDidChangeConfiguration((()=>this.update()))),this.callOnDispose.add(e.onDidChangeModel((()=>this.update()))),this.callOnDispose.add(e.onDidChangeModelLanguage((()=>this.update())))}update(){this.callOnModel.clear(),this.editor.getOption(12)<4||this.editor.getOption(55)||this.editor.hasModel()&&this.callOnModel.add(this.editor.onDidPaste((({range:e})=>{this.trigger(e)})))}trigger(e){const t=this.editor.getSelections();if(null===t||t.length>1)return;const i=this.editor.getModel();if(!i)return;if(this.rangeContainsOnlyWhitespaceCharacters(i,e))return;if(function(e,t){const i=t=>2===(0,E.T)(e,t);return i(t.getStartPosition())||i(t.getEndPosition())}(i,e))return;if(!i.tokenization.isCheapToTokenize(e.getStartPosition().lineNumber))return;const s=this.editor.getOption(12),{tabSize:r,indentSize:l,insertSpaces:c}=i.getOptions(),h=[],u={shiftIndent:e=>o.Y.shiftIndent(e,e.length+1,r,l,c),unshiftIndent:e=>o.Y.unshiftIndent(e,e.length+1,r,l,c)};let g=e.startLineNumber;for(;g<=e.endLineNumber&&this.shouldIgnoreLine(i,g);)g++;if(g>e.endLineNumber)return;let m=i.getLineContent(g);if(!/\S/.test(m.substring(0,e.startColumn-1))){const e=(0,p.$f)(s,i,i.getLanguageId(),g,u,this._languageConfigurationService);if(null!==e){const t=n.UU(m),s=d.c(e,r);if(s!==d.c(t,r)){const e=d.k(s,r,c);h.push({range:new a.Q(g,1,g,t.length+1),text:e}),m=e+m.substring(t.length)}else{const e=(0,p.Yb)(i,g,this._languageConfigurationService);if(0===e||8===e)return}}}const f=g;for(;gi.tokenization.getLineTokens(e),getLanguageId:()=>i.getLanguageId(),getLanguageIdAtPosition:(e,t)=>i.getLanguageIdAtPosition(e,t)},getLineContent:e=>e===f?m:i.getLineContent(e)},o=(0,p.$f)(s,t,i.getLanguageId(),g+1,u,this._languageConfigurationService);if(null!==o){const t=d.c(o,r),s=d.c(n.UU(i.getLineContent(g+1)),r);if(t!==s){const o=t-s;for(let t=g+1;t<=e.endLineNumber;t++){const e=i.getLineContent(t),s=n.UU(e),l=d.c(s,r)+o,u=d.k(l,r,c);u!==s&&h.push({range:new a.Q(t,1,t,s.length+1),text:u})}}}}if(h.length>0){this.editor.pushUndoStop();const e=new O(h,this.editor.getSelection());this.editor.executeCommand("autoIndentOnPaste",e),this.editor.pushUndoStop()}}rangeContainsOnlyWhitespaceCharacters(e,t){const i=e=>0===e.trim().length;let s=!0;if(t.startLineNumber===t.endLineNumber){s=i(e.getLineContent(t.startLineNumber).substring(t.startColumn-1,t.endColumn-1))}else for(let n=t.startLineNumber;n<=t.endLineNumber;n++){const r=e.getLineContent(n);if(n===t.startLineNumber){s=i(r.substring(t.startColumn-1))}else if(n===t.endLineNumber){s=i(r.substring(0,t.endColumn-1))}else s=0===e.getLineFirstNonWhitespaceColumn(n);if(!s)break}return s}shouldIgnoreLine(e,t){e.tokenization.forceTokenization(t);const i=e.getLineFirstNonWhitespaceColumn(t);if(0===i)return!0;const s=e.tokenization.getLineTokens(t);if(s.getCount()>0){const e=s.findTokenIndexAtOffset(i);if(e>=0&&1===s.getStandardTokenType(e))return!0}return!1}dispose(){this.callOnDispose.dispose(),this.callOnModel.dispose()}};function M(e,t,i,s){if(1===e.getLineCount()&&1===e.getLineMaxColumn(1))return;let n="";for(let o=0;o{"use strict";function s(e,t){let i=0;for(let s=0;ss,k:()=>n})},3730:(e,t,i)=>{"use strict";i.d(t,{CN:()=>u,EP:()=>c,P8:()=>d});var s=i(64383),n=i(5662),r=i(83069),o=i(36677),a=i(36456),l=i(79400);class c{constructor(e,t){this.range=e,this.direction=t}}class h{constructor(e,t,i){this.hint=e,this.anchor=t,this.provider=i,this._isResolved=!1}with(e){const t=new h(this.hint,e.anchor,this.provider);return t._isResolved=this._isResolved,t._currentResolve=this._currentResolve,t}async resolve(e){if("function"===typeof this.provider.resolveInlayHint){if(this._currentResolve){if(await this._currentResolve,e.isCancellationRequested)return;return this.resolve(e)}this._isResolved||(this._currentResolve=this._doResolve(e).finally((()=>this._currentResolve=void 0))),await this._currentResolve}}async _doResolve(e){try{const t=await Promise.resolve(this.provider.resolveInlayHint(this.hint,e));this.hint.tooltip=t?.tooltip??this.hint.tooltip,this.hint.label=t?.label??this.hint.label,this.hint.textEdits=t?.textEdits??this.hint.textEdits,this._isResolved=!0}catch(t){(0,s.M_)(t),this._isResolved=!1}}}class d{static{this._emptyInlayHintList=Object.freeze({dispose(){},hints:[]})}static async create(e,t,i,n){const r=[],o=e.ordered(t).reverse().map((e=>i.map((async i=>{try{const s=await e.provideInlayHints(t,i,n);(s?.hints.length||e.onDidChangeInlayHints)&&r.push([s??d._emptyInlayHintList,e])}catch(o){(0,s.M_)(o)}}))));if(await Promise.all(o.flat()),n.isCancellationRequested||t.isDisposed())throw new s.AL;return new d(i,r,t)}constructor(e,t,i){this._disposables=new n.Cm,this.ranges=e,this.provider=new Set;const s=[];for(const[n,r]of t){this._disposables.add(n),this.provider.add(r);for(const e of n.hints){const t=i.validatePosition(e.position);let n="before";const a=d._getRangeAtPosition(i,t);let l;a.getStartPosition().isBefore(t)?(l=o.Q.fromPositions(a.getStartPosition(),t),n="after"):(l=o.Q.fromPositions(t,a.getEndPosition()),n="before"),s.push(new h(e,new c(l,n),r))}}this.items=s.sort(((e,t)=>r.y.compare(e.hint.position,t.hint.position)))}dispose(){this._disposables.dispose()}static _getRangeAtPosition(e,t){const i=t.lineNumber,s=e.getWordAtPosition(t);if(s)return new o.Q(i,s.startColumn,i,s.endColumn);e.tokenization.tokenizeIfCheap(i);const n=e.tokenization.getLineTokens(i),r=t.column-1,a=n.findTokenIndexAtOffset(r);let l=n.getStartOffset(a),c=n.getEndOffset(a);return c-l===1&&(l===r&&a>1?(l=n.getStartOffset(a-1),c=n.getEndOffset(a-1)):c===r&&a{"use strict";var s=i(31450),n=i(57039),r=i(21478),o=i(68250);(0,s.HW)(r.M.ID,r.M,1),n.B2.register(o.u)},21478:(e,t,i)=>{"use strict";i.d(t,{M:()=>H,z:()=>F});var s,n=i(8597),r=i(25890),o=i(90766),a=i(18447),l=i(64383),c=i(5662),h=i(74320),d=i(631),u=i(79400),g=i(37734),p=i(55190),m=i(87908),f=i(7085),_=i(36677),v=i(62083),C=i(16223),b=i(87289),E=i(32500),S=i(56942),y=i(18938),w=i(37927),L=i(3730),R=i(60952),T=i(50091),x=i(14718),k=i(63591),A=i(58591),N=i(66261),I=i(47612),O=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},D=function(e,t){return function(i,s){t(i,s,e)}};class M{constructor(){this._entries=new h.qK(50)}get(e){const t=M._key(e);return this._entries.get(t)}set(e,t){const i=M._key(e);this._entries.set(i,t)}static _key(e){return`${e.uri.toString()}/${e.getVersionId()}`}}const P=(0,k.u1)("IInlayHintsCache");(0,x.v)(P,M,1);class F{constructor(e,t){this.item=e,this.index=t}get part(){const e=this.item.hint.label;return"string"===typeof e?{label:e}:e[this.index]}}class U{constructor(e,t){this.part=e,this.hasTriggerModifier=t}}let H=class{static{s=this}static{this.ID="editor.contrib.InlayHints"}static{this._MAX_DECORATORS=1500}static{this._MAX_LABEL_LEN=43}static get(e){return e.getContribution(s.ID)??void 0}constructor(e,t,i,s,n,r,o){this._editor=e,this._languageFeaturesService=t,this._inlayHintsCache=s,this._commandService=n,this._notificationService=r,this._instaService=o,this._disposables=new c.Cm,this._sessionDisposables=new c.Cm,this._decorationsMetadata=new Map,this._ruleFactory=new g.Qn(this._editor),this._activeRenderMode=0,this._debounceInfo=i.for(t.inlayHintsProvider,"InlayHint",{min:25}),this._disposables.add(t.inlayHintsProvider.onDidChange((()=>this._update()))),this._disposables.add(e.onDidChangeModel((()=>this._update()))),this._disposables.add(e.onDidChangeModelLanguage((()=>this._update()))),this._disposables.add(e.onDidChangeConfiguration((e=>{e.hasChanged(142)&&this._update()}))),this._update()}dispose(){this._sessionDisposables.dispose(),this._removeAllDecorations(),this._disposables.dispose()}_update(){this._sessionDisposables.clear(),this._removeAllDecorations();const e=this._editor.getOption(142);if("off"===e.enabled)return;const t=this._editor.getModel();if(!t||!this._languageFeaturesService.inlayHintsProvider.has(t))return;if("on"===e.enabled)this._activeRenderMode=0;else{let t,i;"onUnlessPressed"===e.enabled?(t=0,i=1):(t=1,i=0),this._activeRenderMode=t,this._sessionDisposables.add(n.Di.getInstance().event((e=>{if(!this._editor.hasModel())return;const s=e.altKey&&e.ctrlKey&&!e.shiftKey&&!e.metaKey?i:t;if(s!==this._activeRenderMode){this._activeRenderMode=s;const e=this._editor.getModel(),t=this._copyInlayHintsWithCurrentAnchor(e);this._updateHintsDecorators([e.getFullModelRange()],t),h.schedule(0)}})))}const i=this._inlayHintsCache.get(t);let s;i&&this._updateHintsDecorators([t.getFullModelRange()],i),this._sessionDisposables.add((0,c.s)((()=>{t.isDisposed()||this._cacheHintsForFastRestore(t)})));const r=new Set,h=new o.uC((async()=>{const e=Date.now();s?.dispose(!0),s=new a.Qi;const i=t.onWillDispose((()=>s?.cancel()));try{const i=s.token,n=await L.P8.create(this._languageFeaturesService.inlayHintsProvider,t,this._getHintsRanges(),i);if(h.delay=this._debounceInfo.update(t,Date.now()-e),i.isCancellationRequested)return void n.dispose();for(const e of n.provider)"function"!==typeof e.onDidChangeInlayHints||r.has(e)||(r.add(e),this._sessionDisposables.add(e.onDidChangeInlayHints((()=>{h.isScheduled()||h.schedule()}))));this._sessionDisposables.add(n),this._updateHintsDecorators(n.ranges,n.items),this._cacheHintsForFastRestore(t)}catch(n){(0,l.dz)(n)}finally{s.dispose(),i.dispose()}}),this._debounceInfo.get(t));this._sessionDisposables.add(h),this._sessionDisposables.add((0,c.s)((()=>s?.dispose(!0)))),h.schedule(0),this._sessionDisposables.add(this._editor.onDidScrollChange((e=>{!e.scrollTopChanged&&h.isScheduled()||h.schedule()}))),this._sessionDisposables.add(this._editor.onDidChangeModelContent((e=>{s?.cancel();const t=Math.max(h.delay,1250);h.schedule(t)}))),this._sessionDisposables.add(this._installDblClickGesture((()=>h.schedule(0)))),this._sessionDisposables.add(this._installLinkGesture()),this._sessionDisposables.add(this._installContextMenu())}_installLinkGesture(){const e=new c.Cm,t=e.add(new w.gi(this._editor)),i=new c.Cm;return e.add(i),e.add(t.onMouseMoveOrRelevantKeyDown((e=>{const[t]=e,s=this._getInlayHintLabelPart(t),n=this._editor.getModel();if(!s||!n)return void i.clear();const r=new a.Qi;i.add((0,c.s)((()=>r.dispose(!0)))),s.item.resolve(r.token),this._activeInlayHintPart=s.part.command||s.part.location?new U(s,t.hasTriggerModifier):void 0;const o=n.validatePosition(s.item.hint.position).lineNumber,l=new _.Q(o,1,o,n.getLineMaxColumn(o)),h=this._getInlineHintsForRange(l);this._updateHintsDecorators([l],h),i.add((0,c.s)((()=>{this._activeInlayHintPart=void 0,this._updateHintsDecorators([l],h)})))}))),e.add(t.onCancel((()=>i.clear()))),e.add(t.onExecute((async e=>{const t=this._getInlayHintLabelPart(e);if(t){const i=t.part;i.location?this._instaService.invokeFunction(R.U,e,this._editor,i.location):v.uB.is(i.command)&&await this._invokeCommand(i.command,t.item)}}))),e}_getInlineHintsForRange(e){const t=new Set;for(const i of this._decorationsMetadata.values())e.containsRange(i.item.anchor.range)&&t.add(i.item);return Array.from(t)}_installDblClickGesture(e){return this._editor.onMouseUp((async t=>{if(2!==t.event.detail)return;const i=this._getInlayHintLabelPart(t);if(i&&(t.event.preventDefault(),await i.item.resolve(a.XO.None),(0,r.EI)(i.item.hint.textEdits))){const t=i.item.hint.textEdits.map((e=>f.k.replace(_.Q.lift(e.range),e.text)));this._editor.executeEdits("inlayHint.default",t),e()}}))}_installContextMenu(){return this._editor.onContextMenu((async e=>{if(!(0,n.sb)(e.event.target))return;const t=this._getInlayHintLabelPart(e);t&&await this._instaService.invokeFunction(R.h,this._editor,e.event.target,t)}))}_getInlayHintLabelPart(e){if(6!==e.target.type)return;const t=e.target.detail.injectedText?.options;return t instanceof b.Ho&&t?.attachedData instanceof F?t.attachedData:void 0}async _invokeCommand(e,t){try{await this._commandService.executeCommand(e.id,...e.arguments??[])}catch(i){this._notificationService.notify({severity:A.AI.Error,source:t.provider.displayName,message:i})}}_cacheHintsForFastRestore(e){const t=this._copyInlayHintsWithCurrentAnchor(e);this._inlayHintsCache.set(e,t)}_copyInlayHintsWithCurrentAnchor(e){const t=new Map;for(const[i,s]of this._decorationsMetadata){if(t.has(s.item))continue;const n=e.getDecorationRange(i);if(n){const e=new L.EP(n,s.item.anchor.direction),i=s.item.with({anchor:e});t.set(s.item,i)}}return Array.from(t.values())}_getHintsRanges(){const e=this._editor.getModel(),t=this._editor.getVisibleRangesPlusViewportAboveBelow(),i=[];for(const s of t.sort(_.Q.compareRangesUsingStarts)){const t=e.validateRange(new _.Q(s.startLineNumber-30,s.startColumn,s.endLineNumber+30,s.endColumn));0!==i.length&&_.Q.areIntersectingOrTouching(i[i.length-1],t)?i[i.length-1]=_.Q.plusRange(i[i.length-1],t):i.push(t)}return i}_updateHintsDecorators(e,t){const i=[],n=(e,t,s,n,r)=>{const o={content:s,inlineClassNameAffectsLetterSpacing:!0,inlineClassName:t.className,cursorStops:n,attachedData:r};i.push({item:e,classNameRef:t,decoration:{range:e.anchor.range,options:{description:"InlayHint",showIfCollapsed:e.anchor.range.isEmpty(),collapseOnReplaceEdit:!e.anchor.range.isEmpty(),stickiness:0,[e.anchor.direction]:0===this._activeRenderMode?o:void 0}}})},o=(e,t)=>{const i=this._ruleFactory.createClassNameRef({width:(a/3|0)+"px",display:"inline-block"});n(e,i,"\u200a",t?C.VW.Right:C.VW.None)},{fontSize:a,fontFamily:l,padding:c,isUniform:h}=this._getLayoutInfo(),d="--code-editorInlayHintsFontFamily";this._editor.getContainerDomNode().style.setProperty(d,l);let u={line:0,totalLen:0};for(const p of t){if(u.line!==p.anchor.range.startLineNumber&&(u={line:p.anchor.range.startLineNumber,totalLen:0}),u.totalLen>s._MAX_LABEL_LEN)continue;p.hint.paddingLeft&&o(p,!1);const e="string"===typeof p.hint.label?[{label:p.hint.label}]:p.hint.label;for(let t=0;t0&&(f=f.slice(0,-v)+"\u2026",_=!0),n(p,this._ruleFactory.createClassNameRef(g),B(f),l&&!p.hint.paddingRight?C.VW.Right:C.VW.None,new F(p,t)),_)break}if(p.hint.paddingRight&&o(p,!0),i.length>s._MAX_DECORATORS)break}const g=[];for(const[s,r]of this._decorationsMetadata){const t=this._editor.getModel()?.getDecorationRange(s);t&&e.some((e=>e.containsRange(t)))&&(g.push(s),r.classNameRef.dispose(),this._decorationsMetadata.delete(s))}const f=p.D.capture(this._editor);this._editor.changeDecorations((e=>{const t=e.deltaDecorations(g,i.map((e=>e.decoration)));for(let s=0;si)&&(n=i);const r=e.fontFamily||s;return{fontSize:n,fontFamily:r,padding:t,isUniform:!t&&r===s&&n===i}}_removeAllDecorations(){this._editor.removeDecorations(Array.from(this._decorationsMetadata.keys()));for(const e of this._decorationsMetadata.values())e.classNameRef.dispose();this._decorationsMetadata.clear()}};function B(e){return e.replace(/[ \t]/g,"\xa0")}H=s=O([D(1,S.ILanguageFeaturesService),D(2,E.ILanguageFeatureDebounceService),D(3,P),D(4,T.d),D(5,A.Ot),D(6,k._Y)],H),T.w.registerCommand("_executeInlayHintProvider",(async(e,...t)=>{const[i,s]=t;(0,d.j)(u.r.isUri(i)),(0,d.j)(_.Q.isIRange(s));const{inlayHintsProvider:n}=e.get(S.ILanguageFeaturesService),r=await e.get(y.ITextModelService).createModelReference(i);try{const e=await L.P8.create(n,r.object.textEditorModel,[_.Q.lift(s)],a.XO.None),t=e.items.map((e=>e.hint));return setTimeout((()=>e.dispose()),0),t}finally{r.dispose()}}))},68250:(e,t,i)=>{"use strict";i.d(t,{u:()=>R});var s=i(90766),n=i(16980),r=i(83069),o=i(87289),a=i(57039),l=i(10154),c=i(18938),h=i(7142),d=i(57286),u=i(21478),g=i(84001),p=i(49099),m=i(56942),f=i(78209),_=i(98067),v=i(3730),C=i(25890),b=i(98031),E=i(67220),S=i(50091),y=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},w=function(e,t){return function(i,s){t(i,s,e)}};class L extends a.mm{constructor(e,t,i,s){super(10,t,e.item.anchor.range,i,s,!0),this.part=e}}let R=class extends d.xJ{constructor(e,t,i,s,n,r,o,a,l){super(e,t,i,r,a,s,n,l),this._resolverService=o,this.hoverOrdinal=6}suggestHoverAnchor(e){if(!u.M.get(this._editor))return null;if(6!==e.target.type)return null;const t=e.target.detail.injectedText?.options;return t instanceof o.Ho&&t.attachedData instanceof u.z?new L(t.attachedData,this,e.event.posx,e.event.posy):null}computeSync(){return[]}computeAsync(e,t,i){return e instanceof L?new s.AE((async t=>{const{part:s}=e;if(await s.item.resolve(i),i.isCancellationRequested)return;let r,o;if("string"===typeof s.item.hint.tooltip?r=(new n.Bc).appendText(s.item.hint.tooltip):s.item.hint.tooltip&&(r=s.item.hint.tooltip),r&&t.emitOne(new d.eH(this,e.range,[r],!1,0)),(0,C.EI)(s.item.hint.textEdits)&&t.emitOne(new d.eH(this,e.range,[(new n.Bc).appendText((0,f.kg)("hint.dbl","Double-click to insert"))],!1,10001)),"string"===typeof s.part.tooltip?o=(new n.Bc).appendText(s.part.tooltip):s.part.tooltip&&(o=s.part.tooltip),o&&t.emitOne(new d.eH(this,e.range,[o],!1,1)),s.part.location||s.part.command){let i;const r="altKey"===this._editor.getOption(78)?_.zx?(0,f.kg)("links.navigate.kb.meta.mac","cmd + click"):(0,f.kg)("links.navigate.kb.meta","ctrl + click"):_.zx?(0,f.kg)("links.navigate.kb.alt.mac","option + click"):(0,f.kg)("links.navigate.kb.alt","alt + click");s.part.location&&s.part.command?i=(new n.Bc).appendText((0,f.kg)("hint.defAndCommand","Go to Definition ({0}), right click for more",r)):s.part.location?i=(new n.Bc).appendText((0,f.kg)("hint.def","Go to Definition ({0})",r)):s.part.command&&(i=new n.Bc(`[${(0,f.kg)("hint.cmd","Execute Command")}](${(0,v.CN)(s.part.command)} "${s.part.command.title}") (${r})`,{isTrusted:!0})),i&&t.emitOne(new d.eH(this,e.range,[i],!1,1e4))}const a=await this._resolveInlayHintLabelPartHover(s,i);for await(const e of a)t.emitOne(e)})):s.AE.EMPTY}async _resolveInlayHintLabelPartHover(e,t){if(!e.part.location)return s.AE.EMPTY;const{uri:i,range:o}=e.part.location,a=await this._resolverService.createModelReference(i);try{const i=a.object.textEditorModel;return this._languageFeaturesService.hoverProvider.has(i)?(0,h.U)(this._languageFeaturesService.hoverProvider,i,new r.y(o.startLineNumber,o.startColumn),t).filter((e=>!(0,n.it)(e.hover.contents))).map((t=>new d.eH(this,e.item.anchor.range,t.hover.contents,!1,2+t.ordinal))):s.AE.EMPTY}finally{a.dispose()}}};R=y([w(1,l.L),w(2,p.C),w(3,b.b),w(4,E.TN),w(5,g.pG),w(6,c.ITextModelService),w(7,m.ILanguageFeaturesService),w(8,S.d)],R)},60952:(e,t,i)=>{"use strict";i.d(t,{U:()=>v,h:()=>_});var s=i(8597),n=i(36921),r=i(18447),o=i(58255),a=i(36677),l=i(18938),c=i(99312),h=i(84226),d=i(27195),u=i(50091),g=i(32848),p=i(47508),m=i(63591),f=i(58591);async function _(e,t,i,h){const g=e.get(l.ITextModelService),_=e.get(p.Z),v=e.get(u.d),C=e.get(m._Y),b=e.get(f.Ot);if(await h.item.resolve(r.XO.None),!h.part.location)return;const E=h.part.location,S=[],y=new Set(d.ZG.getMenuItems(d.D8.EditorContext).map((e=>(0,d.is)(e)?e.command.id:(0,o.b)())));for(const s of c.bn.all())y.has(s.desc.id)&&S.push(new n.rc(s.desc.id,d.Xe.label(s.desc,{renderShortTitle:!0}),void 0,!0,(async()=>{const e=await g.createModelReference(E.uri);try{const i=new c.QS(e.object.textEditorModel,a.Q.getStartPosition(E.range)),n=h.item.anchor.range;await C.invokeFunction(s.runEditorCommand.bind(s),t,i,n)}finally{e.dispose()}})));if(h.part.command){const{command:e}=h.part;S.push(new n.wv),S.push(new n.rc(e.id,e.title,void 0,!0,(async()=>{try{await v.executeCommand(e.id,...e.arguments??[])}catch(t){b.notify({severity:f.AI.Error,source:h.item.provider.displayName,message:t})}})))}const w=t.getOption(128);_.showContextMenu({domForShadowRoot:w?t.getDomNode()??void 0:void 0,getAnchor:()=>{const e=s.BK(i);return{x:e.left,y:e.top+e.height+8}},getActions:()=>S,onHide:()=>{t.focus()},autoSelectFirstItem:!0})}async function v(e,t,i,s){const n=e.get(l.ITextModelService),r=await n.createModelReference(s.uri);await i.invokeWithinContext((async e=>{const n=t.hasSideBySideModifier,o=e.get(g.fN),l=h.x2.inPeekEditor.getValue(o),d=!n&&i.getOption(89)&&!l;return new c.mR({openToSide:n,openInPeek:d,muteMessage:!0},{title:{value:"",original:""},id:"",precondition:void 0}).run(e,new c.QS(r.object.textEditorModel,a.Q.getStartPosition(s.range)),a.Q.lift(s.range))})),r.dispose()}},78244:(e,t,i)=>{"use strict";i.d(t,{PA:()=>r,Vl:()=>n,Wt:()=>s});const s="editor.action.inlineSuggest.commit",n="editor.action.inlineSuggest.showPrevious",r="editor.action.inlineSuggest.showNext"},62051:(e,t,i)=>{"use strict";i.d(t,{p:()=>c});var s=i(31308),n=i(91508),r=i(1245),o=i(32848),a=i(5662),l=i(78209);class c extends a.jG{static{this.inlineSuggestionVisible=new o.N1("inlineSuggestionVisible",!1,(0,l.kg)("inlineSuggestionVisible","Whether an inline suggestion is visible"))}static{this.inlineSuggestionHasIndentation=new o.N1("inlineSuggestionHasIndentation",!1,(0,l.kg)("inlineSuggestionHasIndentation","Whether the inline suggestion starts with whitespace"))}static{this.inlineSuggestionHasIndentationLessThanTabSize=new o.N1("inlineSuggestionHasIndentationLessThanTabSize",!0,(0,l.kg)("inlineSuggestionHasIndentationLessThanTabSize","Whether the inline suggestion starts with whitespace that is less than what would be inserted by tab"))}static{this.suppressSuggestions=new o.N1("inlineSuggestionSuppressSuggestions",void 0,(0,l.kg)("suppressSuggestions","Whether suggestions should be suppressed for the current suggestion"))}constructor(e,t){super(),this.contextKeyService=e,this.model=t,this.inlineCompletionVisible=c.inlineSuggestionVisible.bindTo(this.contextKeyService),this.inlineCompletionSuggestsIndentation=c.inlineSuggestionHasIndentation.bindTo(this.contextKeyService),this.inlineCompletionSuggestsIndentationLessThanTabSize=c.inlineSuggestionHasIndentationLessThanTabSize.bindTo(this.contextKeyService),this.suppressSuggestions=c.suppressSuggestions.bindTo(this.contextKeyService),this._register((0,s.fm)((e=>{const t=this.model.read(e),i=t?.state.read(e),s=!!i?.inlineCompletion&&void 0!==i?.primaryGhostText&&!i?.primaryGhostText.isEmpty();this.inlineCompletionVisible.set(s),i?.primaryGhostText&&i?.inlineCompletion&&this.suppressSuggestions.set(i.inlineCompletion.inlineCompletion.source.inlineCompletions.suppressSuggestions)}))),this._register((0,s.fm)((e=>{const t=this.model.read(e);let i=!1,s=!0;const o=t?.primaryGhostText.read(e);if(t?.selectedSuggestItem&&o&&o.parts.length>0){const{column:e,lines:a}=o.parts[0],l=a[0];if(e<=t.textModel.getLineIndentColumn(o.lineNumber)){let e=(0,n.HG)(l);-1===e&&(e=l.length-1),i=e>0;const o=t.textModel.getOptions().tabSize;s=r.A.visibleColumnFromColumn(l,e+1,o){"use strict";i.d(t,{Pm:()=>I,bo:()=>M});var s,n=i(8597),r=i(5646),o=i(47625),a=i(36921),l=i(25890),c=i(90766),h=i(10350),d=i(5662),u=i(31308),g=i(87958),p=i(98067),m=i(25689),f=i(83069),_=i(62083),v=i(78244),C=i(78209),b=i(57629),E=i(65644),S=i(27195),y=i(50091),w=i(32848),L=i(47508),R=i(63591),T=i(98031),x=i(90651),k=i(61394),A=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},N=function(e,t){return function(i,s){t(i,s,e)}};let I=class extends d.jG{constructor(e,t,i){super(),this.editor=e,this.model=t,this.instantiationService=i,this.alwaysShowToolbar=(0,u.y0)(this,this.editor.onDidChangeConfiguration,(()=>"always"===this.editor.getOption(62).showToolbar)),this.sessionPosition=void 0,this.position=(0,u.un)(this,(e=>{const t=this.model.read(e)?.primaryGhostText.read(e);if(!this.alwaysShowToolbar.read(e)||!t||0===t.parts.length)return this.sessionPosition=void 0,null;const i=t.parts[0].column;this.sessionPosition&&this.sessionPosition.lineNumber!==t.lineNumber&&(this.sessionPosition=void 0);const s=new f.y(t.lineNumber,Math.min(i,this.sessionPosition?.column??Number.MAX_SAFE_INTEGER));return this.sessionPosition=s,s})),this._register((0,u.yC)(((t,i)=>{const s=this.model.read(t);if(!s||!this.alwaysShowToolbar.read(t))return;const n=(0,g.rm)(((t,i)=>{const n=i.add(this.instantiationService.createInstance(M,this.editor,!0,this.position,s.selectedInlineCompletionIndex,s.inlineCompletionsCount,s.activeCommands));return e.addContentWidget(n),i.add((0,d.s)((()=>e.removeContentWidget(n)))),i.add((0,u.fm)((e=>{this.position.read(e)&&s.lastTriggerKind.read(e)!==_.qw.Explicit&&s.triggerExplicitly()}))),n})),r=(0,u.ZX)(this,((e,t)=>!!this.position.read(e)||!!t));i.add((0,u.fm)((e=>{r.read(e)&&n.read(e)})))})))}};I=A([N(2,R._Y)],I);const O=(0,k.pU)("inline-suggestion-hints-next",h.W.chevronRight,(0,C.kg)("parameterHintsNextIcon","Icon for show next parameter hint.")),D=(0,k.pU)("inline-suggestion-hints-previous",h.W.chevronLeft,(0,C.kg)("parameterHintsPreviousIcon","Icon for show previous parameter hint."));let M=class extends d.jG{static{s=this}static{this._dropDownVisible=!1}static get dropDownVisible(){return this._dropDownVisible}static{this.id=0}createCommandAction(e,t,i){const s=new a.rc(e,t,i,!0,(()=>this._commandService.executeCommand(e))),n=this.keybindingService.lookupKeybinding(e,this._contextKeyService);let r=t;return n&&(r=(0,C.kg)({key:"content",comment:["A label","A keybinding"]},"{0} ({1})",t,n.getLabel())),s.tooltip=r,s}constructor(e,t,i,r,o,l,h,d,g,p,f){super(),this.editor=e,this.withBorder=t,this._position=i,this._currentSuggestionIdx=r,this._suggestionCount=o,this._extraCommands=l,this._commandService=h,this.keybindingService=g,this._contextKeyService=p,this._menuService=f,this.id="InlineSuggestionHintsContentWidget"+s.id++,this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this.nodes=(0,n.h)("div.inlineSuggestionsHints",{className:this.withBorder?".withBorder":""},[(0,n.h)("div@toolBar")]),this.previousAction=this.createCommandAction(v.Vl,(0,C.kg)("previous","Previous"),m.L.asClassName(D)),this.availableSuggestionCountAction=new a.rc("inlineSuggestionHints.availableSuggestionCount","",void 0,!1),this.nextAction=this.createCommandAction(v.PA,(0,C.kg)("next","Next"),m.L.asClassName(O)),this.inlineCompletionsActionsMenus=this._register(this._menuService.createMenu(S.D8.InlineCompletionsActions,this._contextKeyService)),this.clearAvailableSuggestionCountLabelDebounced=this._register(new c.uC((()=>{this.availableSuggestionCountAction.label=""}),100)),this.disableButtonsDebounced=this._register(new c.uC((()=>{this.previousAction.enabled=this.nextAction.enabled=!1}),100)),this.toolBar=this._register(d.createInstance(U,this.nodes.toolBar,S.D8.InlineSuggestionToolbar,{menuOptions:{renderShortTitle:!0},toolbarOptions:{primaryGroup:e=>e.startsWith("primary")},actionViewItemProvider:(e,t)=>{if(e instanceof S.Xe)return d.createInstance(F,e,void 0);if(e===this.availableSuggestionCountAction){const t=new P(void 0,e,{label:!0,icon:!1});return t.setClass("availableSuggestionCount"),t}},telemetrySource:"InlineSuggestionToolbar"})),this.toolBar.setPrependedPrimaryActions([this.previousAction,this.availableSuggestionCountAction,this.nextAction]),this._register(this.toolBar.onDidChangeDropdownVisibility((e=>{s._dropDownVisible=e}))),this._register((0,u.fm)((e=>{this._position.read(e),this.editor.layoutContentWidget(this)}))),this._register((0,u.fm)((e=>{const t=this._suggestionCount.read(e),i=this._currentSuggestionIdx.read(e);void 0!==t?(this.clearAvailableSuggestionCountLabelDebounced.cancel(),this.availableSuggestionCountAction.label=`${i+1}/${t}`):this.clearAvailableSuggestionCountLabelDebounced.schedule(),void 0!==t&&t>1?(this.disableButtonsDebounced.cancel(),this.previousAction.enabled=this.nextAction.enabled=!0):this.disableButtonsDebounced.schedule()}))),this._register((0,u.fm)((e=>{const t=this._extraCommands.read(e).map((e=>({class:void 0,id:e.id,enabled:!0,tooltip:e.tooltip||"",label:e.title,run:t=>this._commandService.executeCommand(e.id)})));for(const[i,s]of this.inlineCompletionsActionsMenus.getActions())for(const e of s)e instanceof S.Xe&&t.push(e);t.length>0&&t.unshift(new a.wv),this.toolBar.setAdditionalSecondaryActions(t)})))}getId(){return this.id}getDomNode(){return this.nodes.root}getPosition(){return{position:this._position.get(),preference:[1,2],positionAffinity:3}}};M=s=A([N(6,y.d),N(7,R._Y),N(8,T.b),N(9,w.fN),N(10,S.ez)],M);class P extends r.Z4{constructor(){super(...arguments),this._className=void 0}setClass(e){this._className=e}render(e){super.render(e),this._className&&e.classList.add(this._className)}updateTooltip(){}}class F extends b.oq{updateLabel(){const e=this._keybindingService.lookupKeybinding(this._action.id,this._contextKeyService);if(!e)return super.updateLabel();if(this.label){const t=(0,n.h)("div.keybinding").root;this._register(new o.x(t,p.OS,{disableTitle:!0,...o.l})).set(e),this.label.textContent=this._action.label,this.label.appendChild(t),this.label.classList.add("inlineSuggestionStatusBarItemLabel")}}updateTooltip(){}}let U=class extends E.p{constructor(e,t,i,s,n,r,o,a,l){super(e,{resetMenu:t,...i},s,n,r,o,a,l),this.menuId=t,this.options2=i,this.menuService=s,this.contextKeyService=n,this.menu=this._store.add(this.menuService.createMenu(this.menuId,this.contextKeyService,{emitEventsForSubmenuChanges:!0})),this.additionalActions=[],this.prependedPrimaryActions=[],this._store.add(this.menu.onDidChange((()=>this.updateToolbar()))),this.updateToolbar()}updateToolbar(){const e=[],t=[];(0,b.Ot)(this.menu,this.options2?.menuOptions,{primary:e,secondary:t},this.options2?.toolbarOptions?.primaryGroup,this.options2?.toolbarOptions?.shouldInlineSubmenu,this.options2?.toolbarOptions?.useSeparatorsInPrimaryActions),t.push(...this.additionalActions),e.unshift(...this.prependedPrimaryActions),this.setActions(e,t)}setPrependedPrimaryActions(e){(0,l.aI)(this.prependedPrimaryActions,e,((e,t)=>e===t))||(this.prependedPrimaryActions=e,this.updateToolbar())}setAdditionalSecondaryActions(e){(0,l.aI)(this.additionalActions,e,((e,t)=>e===t))||(this.additionalActions=e,this.updateToolbar())}};U=A([N(3,S.ez),N(4,w.fN),N(5,L.Z),N(6,T.b),N(7,y.d),N(8,x.k)],U)},80409:(e,t,i)=>{"use strict";var s=i(31450),n=i(57039),r=i(31308),o=i(49154),a=i(60002),l=i(78244),c=i(62051),h=i(8597),d=i(5662);var u=i(11007),g=i(90766),p=i(18447),m=i(87958),f=i(13850),_=i(631),v=i(36999),C=i(38844),b=i(83069),E=i(32500),S=i(56942),y=i(80789),w=i(41234),L=i(91508),R=i(73157),T=i(87908),x=i(36677),k=i(99020),A=i(10154),N=i(16223),I=i(87469),O=i(25521),D=i(35600),M=i(92674),P=i(73401),F=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},U=function(e,t){return function(i,s){t(i,s,e)}};const H="ghost-text";let B=class extends d.jG{constructor(e,t,i){super(),this.editor=e,this.model=t,this.languageService=i,this.isDisposed=(0,r.FY)(this,!1),this.currentTextModel=(0,r.y0)(this,this.editor.onDidChangeModel,(()=>this.editor.getModel())),this.uiState=(0,r.un)(this,(e=>{if(this.isDisposed.read(e))return;const t=this.currentTextModel.read(e);if(t!==this.model.targetTextModel.read(e))return;const i=this.model.ghostText.read(e);if(!i)return;const s=i instanceof M.Vs?i.columnRange:void 0,n=[],r=[];function o(e,t){if(r.length>0){const i=r[r.length-1];t&&i.decorations.push(new O.d(i.content.length+1,i.content.length+1+e[0].length,t,0)),i.content+=e[0],e=e.slice(1)}for(const i of e)r.push({content:i,decorations:t?[new O.d(1,i.length+1,t,0)]:[]})}const a=t.getLineContent(i.lineNumber);let l,c=0;for(const d of i.parts){let e=d.lines;void 0===l?(n.push({column:d.column,text:e[0],preview:d.preview}),e=e.slice(1)):o([a.substring(c,d.column-1)],void 0),e.length>0&&(o(e,H),void 0===l&&d.column<=a.length&&(l=d.column)),c=d.column-1}void 0!==l&&o([a.substring(c)],void 0);const h=void 0!==l?new P.GM(l,a.length+1):void 0;return{replacedRange:s,inlineTexts:n,additionalLines:r,hiddenRange:h,lineNumber:i.lineNumber,additionalReservedLineCount:this.model.minReservedLineCount.read(e),targetTextModel:t}})),this.decorations=(0,r.un)(this,(e=>{const t=this.uiState.read(e);if(!t)return[];const i=[];t.replacedRange&&i.push({range:t.replacedRange.toRange(t.lineNumber),options:{inlineClassName:"inline-completion-text-to-replace",description:"GhostTextReplacement"}}),t.hiddenRange&&i.push({range:t.hiddenRange.toRange(t.lineNumber),options:{inlineClassName:"ghost-text-hidden",description:"ghost-text-hidden"}});for(const s of t.inlineTexts)i.push({range:x.Q.fromPositions(new b.y(t.lineNumber,s.column)),options:{description:H,after:{content:s.text,inlineClassName:s.preview?"ghost-text-decoration-preview":"ghost-text-decoration",cursorStops:N.VW.Left},showIfCollapsed:!0}});return i})),this.additionalLinesWidget=this._register(new W(this.editor,this.languageService.languageIdCodec,(0,r.un)((e=>{const t=this.uiState.read(e);return t?{lineNumber:t.lineNumber,additionalLines:t.additionalLines,minReservedLineCount:t.additionalReservedLineCount,targetTextModel:t.targetTextModel}:void 0})))),this._register((0,d.s)((()=>{this.isDisposed.set(!0,void 0)}))),this._register((0,P.pY)(this.editor,this.decorations))}ownsViewZone(e){return this.additionalLinesWidget.viewZoneId===e}};B=F([U(2,A.L)],B);class W extends d.jG{get viewZoneId(){return this._viewZoneId}constructor(e,t,i){super(),this.editor=e,this.languageIdCodec=t,this.lines=i,this._viewZoneId=void 0,this.editorOptionsChanged=(0,r.yQ)("editorOptionChanged",w.Jh.filter(this.editor.onDidChangeConfiguration,(e=>e.hasChanged(33)||e.hasChanged(118)||e.hasChanged(100)||e.hasChanged(95)||e.hasChanged(51)||e.hasChanged(50)||e.hasChanged(67)))),this._register((0,r.fm)((e=>{const t=this.lines.read(e);this.editorOptionsChanged.read(e),t?this.updateLines(t.lineNumber,t.additionalLines,t.minReservedLineCount):this.clear()})))}dispose(){super.dispose(),this.clear()}clear(){this.editor.changeViewZones((e=>{this._viewZoneId&&(e.removeZone(this._viewZoneId),this._viewZoneId=void 0)}))}updateLines(e,t,i){const s=this.editor.getModel();if(!s)return;const{tabSize:n}=s.getOptions();this.editor.changeViewZones((s=>{this._viewZoneId&&(s.removeZone(this._viewZoneId),this._viewZoneId=void 0);const r=Math.max(t.length,i);if(r>0){const i=document.createElement("div");!function(e,t,i,s,n){const r=s.get(33),o=s.get(118),a="none",l=s.get(95),c=s.get(51),h=s.get(50),d=s.get(67),u=new k.fe(1e4);u.appendString('
    ');for(let m=0,f=i.length;m');const g=L.aC(s),p=L.E_(s),f=I.f.createEmpty(s,n);(0,D.UW)(new D.zL(h.isMonospace&&!r,h.canUseHalfwidthRightwardsArrow,s,!1,g,p,0,f,e.decorations,t,0,h.spaceWidth,h.middotWidth,h.wsmiddotWidth,o,a,l,c!==T.Bc.OFF,null),u),u.appendString("
    ")}u.appendString(""),(0,R.M)(e,h);const g=u.build(),p=V?V.createHTML(g):g;e.innerHTML=p}(i,n,t,this.editor.getOptions(),this.languageIdCodec),this._viewZoneId=s.addZone({afterLineNumber:e,heightInLines:r,domNode:i,afterColumnAffinity:1})}}))}}const V=(0,y.H)("editorGhostText",{createHTML:e=>e});var z=i(64317),G=i(25890),j=i(46041),K=i(51241),Y=i(64383),q=i(7085),$=i(75326),Q=i(75295),X=i(50973),Z=i(62083),J=i(17469),ee=i(26690),te=i(20940),ie=i(83993);function se(e,t,i){const s=i?e.range.intersectRanges(i):e.range;if(!s)return e;const n=t.getValueInRange(s,1),r=(0,L.Qp)(n,e.text),o=X.W.ofText(n.substring(0,r)).addToPosition(e.range.getStartPosition()),a=e.text.substring(r),l=x.Q.fromPositions(o,e.range.getEndPosition());return new Q.WR(l,a)}function ne(e,t){return e.text.startsWith(t.text)&&(i=e.range,(s=t.range).getStartPosition().equals(i.getStartPosition())&&s.getEndPosition().isBeforeOrEqual(i.getEndPosition()));var i,s}function re(e,t,i,s,n=0){let r=se(e,t);if(r.range.endLineNumber!==r.range.startLineNumber)return;const o=t.getLineContent(r.range.startLineNumber),a=(0,L.UU)(o).length;if(r.range.startColumn-1<=a){const e=(0,L.UU)(r.text).length,t=o.substring(r.range.startColumn-1,a),[i,s]=[r.range.getStartPosition(),r.range.getEndPosition()],n=i.column+t.length<=s.column?i.delta(0,t.length):s,l=x.Q.fromPositions(n,s),c=r.text.startsWith(t)?r.text.substring(t.length):r.text.substring(e);r=new Q.WR(l,c)}const l=t.getValueInRange(r.range),c=function(e,t){if(oe?.originalValue===e&&oe?.newValue===t)return oe?.changes;{let i=le(e,t,!0);if(i){const s=ae(i);if(s>0){const n=le(e,t,!1);n&&ae(n)0===e.originalLength));if(e.length>1||1===e.length&&e[0].originalStart!==l.length)return}const u=r.text.length-n;for(const g of c){const e=r.range.startColumn+g.originalStart+g.originalLength;if("subwordSmart"===i&&s&&s.lineNumber===r.range.startLineNumber&&e0)return;if(0===g.modifiedLength)continue;const t=g.modifiedStart+g.modifiedLength,n=Math.max(g.modifiedStart,Math.min(t,u)),o=r.text.substring(g.modifiedStart,n),a=r.text.substring(n,Math.max(g.modifiedStart,t));o.length>0&&d.push(new M.yP(e,o,!1)),a.length>0&&d.push(new M.yP(e,a,!0))}return new M.xD(h,d)}let oe;function ae(e){let t=0;for(const i of e)t+=i.originalLength;return t}function le(e,t,i){if(e.length>5e3||t.length>5e3)return;function s(e){let t=0;for(let i=0,s=e.length;it&&(t=s)}return t}const n=Math.max(s(e),s(t));function r(e){if(e<0)throw new Error("unexpected");return n+e+1}function o(e){let t=0,s=0;const n=new Int32Array(e.length);for(let o=0,a=e.length;oa},{getElements:()=>l}).ComputeDiff(!1).changes}var ce=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},he=function(e,t){return function(i,s){t(i,s,e)}};let de=class extends d.jG{constructor(e,t,i,s,n){super(),this.textModel=e,this.versionId=t,this._debounceValue=i,this.languageFeaturesService=s,this.languageConfigurationService=n,this._updateOperation=this._register(new d.HE),this.inlineCompletions=(0,r.X2)("inlineCompletions",void 0),this.suggestWidgetInlineCompletions=(0,r.X2)("suggestWidgetInlineCompletions",void 0),this._register(this.textModel.onDidChangeContent((()=>{this._updateOperation.clear()})))}fetch(e,t,i){const s=new ue(e,t,this.textModel.getVersionId()),n=t.selectedSuggestionInfo?this.suggestWidgetInlineCompletions:this.inlineCompletions;if(this._updateOperation.value?.request.satisfies(s))return this._updateOperation.value.promise;if(n.get()?.request.satisfies(s))return Promise.resolve(!0);const o=!!this._updateOperation.value;this._updateOperation.clear();const a=new p.Qi,l=(async()=>{var l,c;if((o||t.triggerKind===Z.qw.Automatic)&&await(l=this._debounceValue.get(this.textModel),c=a.token,new Promise((e=>{let t;const i=setTimeout((()=>{t&&t.dispose(),e()}),l);c&&(t=c.onCancellationRequested((()=>{clearTimeout(i),t&&t.dispose(),e()})))}))),a.token.isCancellationRequested||this._store.isDisposed||this.textModel.getVersionId()!==s.versionId)return!1;const h=new Date,d=await(0,te.Yk)(this.languageFeaturesService.inlineCompletionsProvider,e,this.textModel,t,a.token,this.languageConfigurationService);if(a.token.isCancellationRequested||this._store.isDisposed||this.textModel.getVersionId()!==s.versionId)return!1;const u=new Date;this._debounceValue.update(this.textModel,u.getTime()-h.getTime());const g=new pe(d,s,this.textModel,this.versionId);if(i){const t=i.toInlineCompletion(void 0);i.canBeReused(this.textModel,e)&&!d.has(t)&&g.prepend(i.inlineCompletion,t.range,!0)}return this._updateOperation.clear(),(0,r.Rn)((e=>{n.set(g,e)})),!0})(),c=new ge(s,a,l);return this._updateOperation.value=c,l}clear(e){this._updateOperation.clear(),this.inlineCompletions.set(void 0,e),this.suggestWidgetInlineCompletions.set(void 0,e)}clearSuggestWidgetInlineCompletions(e){this._updateOperation.value?.request.context.selectedSuggestionInfo&&this._updateOperation.clear(),this.suggestWidgetInlineCompletions.set(void 0,e)}cancelUpdate(){this._updateOperation.clear()}};de=ce([he(3,S.ILanguageFeaturesService),he(4,J.JZ)],de);class ue{constructor(e,t,i){this.position=e,this.context=t,this.versionId=i}satisfies(e){return this.position.equals(e.position)&&(0,K.KC)(this.context.selectedSuggestionInfo,e.context.selectedSuggestionInfo,(0,K.r)())&&(e.context.triggerKind===Z.qw.Automatic||this.context.triggerKind===Z.qw.Explicit)&&this.versionId===e.versionId}}class ge{constructor(e,t,i){this.request=e,this.cancellationTokenSource=t,this.promise=i}dispose(){this.cancellationTokenSource.cancel()}}class pe{get inlineCompletions(){return this._inlineCompletions}constructor(e,t,i,s){this.inlineCompletionProviderResult=e,this.request=t,this._textModel=i,this._versionId=s,this._refCount=1,this._prependedInlineCompletionItems=[];const n=i.deltaDecorations([],e.completions.map((e=>({range:e.range,options:{description:"inline-completion-tracking-range"}}))));this._inlineCompletions=e.completions.map(((e,t)=>new me(e,n[t],this._textModel,this._versionId)))}clone(){return this._refCount++,this}dispose(){if(this._refCount--,0===this._refCount){setTimeout((()=>{this._textModel.isDisposed()||this._textModel.deltaDecorations(this._inlineCompletions.map((e=>e.decorationId)),[])}),0),this.inlineCompletionProviderResult.dispose();for(const e of this._prependedInlineCompletionItems)e.source.removeRef()}}prepend(e,t,i){i&&e.source.addRef();const s=this._textModel.deltaDecorations([],[{range:t,options:{description:"inline-completion-tracking-range"}}])[0];this._inlineCompletions.unshift(new me(e,s,this._textModel,this._versionId)),this._prependedInlineCompletionItems.push(e)}}class me{get forwardStable(){return this.inlineCompletion.source.inlineCompletions.enableForwardStability??!1}constructor(e,t,i,s){this.inlineCompletion=e,this.decorationId=t,this._textModel=i,this._modelVersion=s,this.semanticId=JSON.stringify([this.inlineCompletion.filterText,this.inlineCompletion.insertText,this.inlineCompletion.range.getStartPosition().toString()]),this._updatedRange=(0,r.C)({owner:this,equalsFn:x.Q.equalsRange},(e=>(this._modelVersion.read(e),this._textModel.getDecorationRange(this.decorationId))))}toInlineCompletion(e){return this.inlineCompletion.withRange(this._updatedRange.read(e)??fe)}toSingleTextEdit(e){return new Q.WR(this._updatedRange.read(e)??fe,this.inlineCompletion.insertText)}isVisible(e,t,i){const s=se(this._toFilterTextReplacement(i),e),n=this._updatedRange.read(i);if(!n||!this.inlineCompletion.range.getStartPosition().equals(n.getStartPosition())||t.lineNumber!==s.range.startLineNumber)return!1;const r=e.getValueInRange(s.range,1),o=s.text,a=Math.max(0,t.column-s.range.startColumn);let l=o.substring(0,a),c=o.substring(a),h=r.substring(0,a),d=r.substring(a);const u=e.getLineIndentColumn(s.range.startLineNumber);return s.range.startColumn<=u&&(h=h.trimStart(),0===h.length&&(d=d.trimStart()),l=l.trimStart(),0===l.length&&(c=c.trimStart())),l.startsWith(h)&&!!(0,ee.dE)(d,c)}canBeReused(e,t){const i=this._updatedRange.read(void 0);return!!i&&i.containsPosition(t)&&this.isVisible(e,t,void 0)&&X.W.ofRange(i).isGreaterThanOrEqualTo(X.W.ofRange(this.inlineCompletion.range))}_toFilterTextReplacement(e){return new Q.WR(this._updatedRange.read(e)??fe,this.inlineCompletion.filterText)}}const fe=new x.Q(1,1,1,1);var _e=i(30936),ve=i(50091),Ce=i(63591),be=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ee=function(e,t){return function(i,s){t(i,s,e)}};let Se=class extends d.jG{get isAcceptingPartially(){return this._isAcceptingPartially}constructor(e,t,i,s,n,o,a,l,c,h,d,u){let g;super(),this.textModel=e,this.selectedSuggestItem=t,this._textModelVersionId=i,this._positions=s,this._debounceValue=n,this._suggestPreviewEnabled=o,this._suggestPreviewMode=a,this._inlineSuggestMode=l,this._enabled=c,this._instantiationService=h,this._commandService=d,this._languageConfigurationService=u,this._source=this._register(this._instantiationService.createInstance(de,this.textModel,this._textModelVersionId,this._debounceValue)),this._isActive=(0,r.FY)(this,!1),this._forceUpdateExplicitlySignal=(0,r.Yd)(this),this._selectedInlineCompletionId=(0,r.FY)(this,void 0),this._primaryPosition=(0,r.un)(this,(e=>this._positions.read(e)[0]??new b.y(1,1))),this._isAcceptingPartially=!1,this._preserveCurrentCompletionReasons=new Set([ye.Redo,ye.Undo,ye.AcceptWord]),this._fetchInlineCompletionsPromise=(0,r.nb)({owner:this,createEmptyChangeSummary:()=>({preserveCurrentCompletion:!1,inlineCompletionTriggerKind:Z.qw.Automatic}),handleChange:(e,t)=>(e.didChange(this._textModelVersionId)&&this._preserveCurrentCompletionReasons.has(this._getReason(e.change))?t.preserveCurrentCompletion=!0:e.didChange(this._forceUpdateExplicitlySignal)&&(t.inlineCompletionTriggerKind=Z.qw.Explicit),!0)},((e,t)=>{this._forceUpdateExplicitlySignal.read(e);if(!(this._enabled.read(e)&&this.selectedSuggestItem.read(e)||this._isActive.read(e)))return void this._source.cancelUpdate();this._textModelVersionId.read(e);const i=this._source.suggestWidgetInlineCompletions.get(),s=this.selectedSuggestItem.read(e);if(i&&!s){const e=this._source.inlineCompletions.get();(0,r.Rn)((t=>{(!e||i.request.versionId>e.request.versionId)&&this._source.inlineCompletions.set(i.clone(),t),this._source.clearSuggestWidgetInlineCompletions(t)}))}const n=this._primaryPosition.read(e),o={triggerKind:t.inlineCompletionTriggerKind,selectedSuggestionInfo:s?.toSelectedSuggestionInfo()},a=this.selectedInlineCompletion.get(),l=t.preserveCurrentCompletion||a?.forwardStable?a:void 0;return this._source.fetch(n,o,l)})),this._filteredInlineCompletionItems=(0,r.C)({owner:this,equalsFn:(0,K.S3)()},(e=>{const t=this._source.inlineCompletions.read(e);if(!t)return[];const i=this._primaryPosition.read(e),s=t.inlineCompletions.filter((t=>t.isVisible(this.textModel,i,e)));return s})),this.selectedInlineCompletionIndex=(0,r.un)(this,(e=>{const t=this._selectedInlineCompletionId.read(e),i=this._filteredInlineCompletionItems.read(e),s=void 0===this._selectedInlineCompletionId?-1:i.findIndex((e=>e.semanticId===t));return-1===s?(this._selectedInlineCompletionId.set(void 0,void 0),0):s})),this.selectedInlineCompletion=(0,r.un)(this,(e=>this._filteredInlineCompletionItems.read(e)[this.selectedInlineCompletionIndex.read(e)])),this.activeCommands=(0,r.C)({owner:this,equalsFn:(0,K.S3)()},(e=>this.selectedInlineCompletion.read(e)?.inlineCompletion.source.inlineCompletions.commands??[])),this.lastTriggerKind=this._source.inlineCompletions.map(this,(e=>e?.request.context.triggerKind)),this.inlineCompletionsCount=(0,r.un)(this,(e=>this.lastTriggerKind.read(e)===Z.qw.Explicit?this._filteredInlineCompletionItems.read(e).length:void 0)),this.state=(0,r.C)({owner:this,equalsFn:(e,t)=>e&&t?(0,M.AL)(e.ghostTexts,t.ghostTexts)&&e.inlineCompletion===t.inlineCompletion&&e.suggestItem===t.suggestItem:e===t},(e=>{const t=this.textModel,i=this.selectedSuggestItem.read(e);if(i){const s=se(i.toSingleTextEdit(),t),n=this._computeAugmentation(s,e);if(!this._suggestPreviewEnabled.read(e)&&!n)return;const r=n?.edit??s,o=n?n.edit.text.length-s.text.length:0,a=this._suggestPreviewMode.read(e),l=this._positions.read(e),c=[r,...we(this.textModel,l,r)],h=c.map(((e,i)=>re(e,t,a,l[i],o))).filter(_.O9);return{edits:c,primaryGhostText:h[0]??new M.xD(r.range.endLineNumber,[]),ghostTexts:h,inlineCompletion:n?.completion,suggestItem:i}}{if(!this._isActive.read(e))return;const i=this.selectedInlineCompletion.read(e);if(!i)return;const s=i.toSingleTextEdit(e),n=this._inlineSuggestMode.read(e),r=this._positions.read(e),o=[s,...we(this.textModel,r,s)],a=o.map(((e,i)=>re(e,t,n,r[i],0))).filter(_.O9);if(!a[0])return;return{edits:o,primaryGhostText:a[0],ghostTexts:a,inlineCompletion:i,suggestItem:void 0}}})),this.ghostTexts=(0,r.C)({owner:this,equalsFn:M.AL},(e=>{const t=this.state.read(e);if(t)return t.ghostTexts})),this.primaryGhostText=(0,r.C)({owner:this,equalsFn:M.x9},(e=>{const t=this.state.read(e);if(t)return t?.primaryGhostText})),this._register((0,r.OI)(this._fetchInlineCompletionsPromise)),this._register((0,r.fm)((e=>{const t=this.state.read(e),i=t?.inlineCompletion;if(i?.semanticId!==g?.semanticId&&(g=i,i)){const e=i.inlineCompletion,t=e.source;t.provider.handleItemDidShow?.(t.inlineCompletions,e.sourceInlineCompletion,e.insertText)}})))}_getReason(e){return e?.isUndoing?ye.Undo:e?.isRedoing?ye.Redo:this.isAcceptingPartially?ye.AcceptWord:ye.Other}async trigger(e){this._isActive.set(!0,e),await this._fetchInlineCompletionsPromise.get()}async triggerExplicitly(e){(0,r.PO)(e,(e=>{this._isActive.set(!0,e),this._forceUpdateExplicitlySignal.trigger(e)})),await this._fetchInlineCompletionsPromise.get()}stop(e){(0,r.PO)(e,(e=>{this._isActive.set(!1,e),this._source.clear(e)}))}_computeAugmentation(e,t){const i=this.textModel,s=this._source.suggestWidgetInlineCompletions.read(t),n=s?s.inlineCompletions:[this.selectedInlineCompletion.read(t)].filter(_.O9);return(0,j.oH)(n,(s=>{let n=s.toSingleTextEdit(t);return n=se(n,i,x.Q.fromPositions(n.range.getStartPosition(),e.range.getEndPosition())),ne(n,e)?{completion:s,edit:n}:void 0}))}async _deltaSelectedInlineCompletionIndex(e){await this.triggerExplicitly();const t=this._filteredInlineCompletionItems.get()||[];if(t.length>0){const i=(this.selectedInlineCompletionIndex.get()+e+t.length)%t.length;this._selectedInlineCompletionId.set(t[i].semanticId,void 0)}else this._selectedInlineCompletionId.set(void 0,void 0)}async next(){await this._deltaSelectedInlineCompletionIndex(1)}async previous(){await this._deltaSelectedInlineCompletionIndex(-1)}async accept(e){if(e.getModel()!==this.textModel)throw new Y.D7;const t=this.state.get();if(!t||t.primaryGhostText.isEmpty()||!t.inlineCompletion)return;const i=t.inlineCompletion.toInlineCompletion(void 0);if(i.command&&i.source.addRef(),e.pushUndoStop(),i.snippetInfo)e.executeEdits("inlineSuggestion.accept",[q.k.replace(i.range,""),...i.additionalTextEdits]),e.setPosition(i.snippetInfo.range.getStartPosition(),"inlineCompletionAccept"),_e.O.get(e)?.insert(i.snippetInfo.snippet,{undoStopBefore:!1});else{const s=t.edits,n=Le(s).map((e=>$.L.fromPositions(e)));e.executeEdits("inlineSuggestion.accept",[...s.map((e=>q.k.replace(e.range,e.text))),...i.additionalTextEdits]),e.setSelections(n,"inlineCompletionAccept")}this.stop(),i.command&&(await this._commandService.executeCommand(i.command.id,...i.command.arguments||[]).then(void 0,Y.M_),i.source.removeRef())}async acceptNextWord(e){await this._acceptNext(e,((e,t)=>{const i=this.textModel.getLanguageIdAtPosition(e.lineNumber,e.column),s=this._languageConfigurationService.getLanguageConfiguration(i),n=new RegExp(s.wordDefinition.source,s.wordDefinition.flags.replace("g","")),r=t.match(n);let o=0;o=r&&void 0!==r.index?0===r.index?r[0].length:r.index:t.length;const a=/\s+/g.exec(t);return a&&void 0!==a.index&&a.index+a[0].length{const i=t.match(/\n/);return i&&void 0!==i.index?i.index+1:t.length}),1)}async _acceptNext(e,t,i){if(e.getModel()!==this.textModel)throw new Y.D7;const s=this.state.get();if(!s||s.primaryGhostText.isEmpty()||!s.inlineCompletion)return;const n=s.primaryGhostText,r=s.inlineCompletion.toInlineCompletion(void 0);if(r.snippetInfo||r.filterText!==r.insertText)return void await this.accept(e);const o=n.parts[0],a=new b.y(n.lineNumber,o.column),l=o.text,c=t(a,l);if(c===l.length&&1===n.parts.length)return void this.accept(e);const h=l.substring(0,c),d=this._positions.get(),u=d[0];r.source.addRef();try{this._isAcceptingPartially=!0;try{e.pushUndoStop();const t=x.Q.fromPositions(u,a),i=e.getModel().getValueInRange(t)+h,s=new Q.WR(t,i),n=[s,...we(this.textModel,d,s)],r=Le(n).map((e=>$.L.fromPositions(e)));e.executeEdits("inlineSuggestion.accept",n.map((e=>q.k.replace(e.range,e.text)))),e.setSelections(r,"inlineCompletionPartialAccept"),e.revealPositionInCenterIfOutsideViewport(e.getPosition(),1)}finally{this._isAcceptingPartially=!1}if(r.source.provider.handlePartialAccept){const t=x.Q.fromPositions(r.range.getStartPosition(),X.W.ofText(h).addToPosition(a)),s=e.getModel().getValueInRange(t,1);r.source.provider.handlePartialAccept(r.source.inlineCompletions,r.sourceInlineCompletion,s.length,{kind:i})}}finally{r.source.removeRef()}}handleSuggestAccepted(e){const t=se(e.toSingleTextEdit(),this.textModel),i=this._computeAugmentation(t,void 0);if(!i)return;const s=i.completion.inlineCompletion;s.source.provider.handlePartialAccept?.(s.source.inlineCompletions,s.sourceInlineCompletion,t.text.length,{kind:2})}};var ye;function we(e,t,i){if(1===t.length)return[];const s=t[0],n=t.slice(1),r=i.range.getStartPosition(),o=i.range.getEndPosition(),a=e.getValueInRange(x.Q.fromPositions(s,o)),l=(0,P.tN)(s,r);if(l.lineNumber<1)return(0,Y.dz)(new Y.D7(`positionWithinTextEdit line number should be bigger than 0.\n\t\t\tInvalid subtraction between ${s.toString()} and ${r.toString()}`)),[];const c=function(e,t){let i="";const s=(0,L.en)(e);for(let n=t.lineNumber-1;n{const i=(0,P.OA)((0,P.tN)(t,r),o),s=e.getValueInRange(x.Q.fromPositions(t,i)),n=(0,L.Qp)(a,s),l=x.Q.fromPositions(t,t.delta(0,n));return new Q.WR(l,c)}))}function Le(e){const t=G.t9.createSortPermutation(e,(0,G.VE)((e=>e.range),x.Q.compareRangesUsingStarts)),i=new Q.mF(t.apply(e)).getNewRanges();return t.inverse().apply(i).map((e=>e.getEndPosition()))}Se=be([Ee(9,Ce._Y),Ee(10,ve.d),Ee(11,J.JZ)],Se),function(e){e[e.Undo=0]="Undo",e[e.Redo=1]="Redo",e[e.AcceptWord=2]="AcceptWord",e[e.Other=3]="Other"}(ye||(ye={}));var Re=i(29319),Te=i(38280),xe=i(90870);class ke extends d.jG{get selectedItem(){return this._currentSuggestItemInfo}constructor(e,t,i){super(),this.editor=e,this.suggestControllerPreselector=t,this.onWillAccept=i,this.isSuggestWidgetVisible=!1,this.isShiftKeyPressed=!1,this._isActive=!1,this._currentSuggestItemInfo=void 0,this._onDidSelectedItemChange=this._register(new w.vl),this.onDidSelectedItemChange=this._onDidSelectedItemChange.event,this._register(e.onKeyDown((e=>{e.shiftKey&&!this.isShiftKeyPressed&&(this.isShiftKeyPressed=!0,this.update(this._isActive))}))),this._register(e.onKeyUp((e=>{e.shiftKey&&this.isShiftKeyPressed&&(this.isShiftKeyPressed=!1,this.update(this._isActive))})));const s=xe.D.get(this.editor);if(s){this._register(s.registerSelector({priority:100,select:(e,t,i)=>{const n=this.editor.getModel();if(!n)return-1;const r=this.suggestControllerPreselector(),o=r?se(r,n):void 0;if(!o)return-1;const a=b.y.lift(t),l=i.map(((e,t)=>{const i=se(Ae.fromSuggestion(s,n,a,e,this.isShiftKeyPressed).toSingleTextEdit(),n);return{index:t,valid:ne(o,i),prefixLength:i.text.length,suggestItem:e}})).filter((e=>e&&e.valid&&e.prefixLength>0)),c=(0,j.Cn)(l,(0,G.VE)((e=>e.prefixLength),G.U9));return c?c.index:-1}}));let e=!1;const t=()=>{e||(e=!0,this._register(s.widget.value.onDidShow((()=>{this.isSuggestWidgetVisible=!0,this.update(!0)}))),this._register(s.widget.value.onDidHide((()=>{this.isSuggestWidgetVisible=!1,this.update(!1)}))),this._register(s.widget.value.onDidFocus((()=>{this.isSuggestWidgetVisible=!0,this.update(!0)}))))};this._register(w.Jh.once(s.model.onDidTrigger)((e=>{t()}))),this._register(s.onWillInsertSuggestItem((e=>{const t=this.editor.getPosition(),i=this.editor.getModel();if(!t||!i)return;const n=Ae.fromSuggestion(s,i,t,e.item,this.isShiftKeyPressed);this.onWillAccept(n)})))}this.update(this._isActive)}update(e){const t=this.getSuggestItemInfo();this._isActive===e&&function(e,t){if(e===t)return!0;if(!e||!t)return!1;return e.equals(t)}(this._currentSuggestItemInfo,t)||(this._isActive=e,this._currentSuggestItemInfo=t,this._onDidSelectedItemChange.fire())}getSuggestItemInfo(){const e=xe.D.get(this.editor);if(!e||!this.isSuggestWidgetVisible)return;const t=e.widget.value.getFocusedItem(),i=this.editor.getPosition(),s=this.editor.getModel();return t&&i&&s?Ae.fromSuggestion(e,s,i,t.item,this.isShiftKeyPressed):void 0}stopForceRenderingAbove(){const e=xe.D.get(this.editor);e?.stopForceRenderingAbove()}forceRenderingAbove(){const e=xe.D.get(this.editor);e?.forceRenderingAbove()}}class Ae{static fromSuggestion(e,t,i,s,n){let{insertText:r}=s.completion,o=!1;if(4&s.completion.insertTextRules){const e=(new Re.fr).parse(r);e.children.length<100&&Te.O.adjustWhitespace(t,i,!0,e),r=e.toString(),o=!0}const a=e.getOverwriteInfo(s,n);return new Ae(x.Q.fromPositions(i.delta(0,-a.overwriteBefore),i.delta(0,Math.max(a.overwriteAfter,0))),r,s.completion.kind,o)}constructor(e,t,i,s){this.range=e,this.insertText=t,this.completionItemKind=i,this.isSnippetText=s}equals(e){return this.range.equalsRange(e.range)&&this.insertText===e.insertText&&this.completionItemKind===e.completionItemKind&&this.isSnippetText===e.isSnippetText}toSelectedSuggestionInfo(){return new Z.GE(this.range,this.insertText,this.completionItemKind,this.isSnippetText)}toSingleTextEdit(){return new Q.WR(this.range,this.insertText)}}var Ne,Ie=i(78209),Oe=i(253),De=i(87213),Me=i(84001),Pe=i(32848),Fe=i(98031),Ue=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},He=function(e,t){return function(i,s){t(i,s,e)}};let Be=class extends d.jG{static{Ne=this}static{this.ID="editor.contrib.inlineCompletionsController"}static get(e){return e.getContribution(Ne.ID)}constructor(e,t,i,s,n,o,a,u,E,S){super(),this.editor=e,this._instantiationService=t,this._contextKeyService=i,this._configurationService=s,this._commandService=n,this._debounceService=o,this._languageFeaturesService=a,this._accessibilitySignalService=u,this._keybindingService=E,this._accessibilityService=S,this._editorObs=(0,C.Ud)(this.editor),this._positions=(0,r.un)(this,(e=>this._editorObs.selections.read(e)?.map((e=>e.getEndPosition()))??[new b.y(1,1)])),this._suggestWidgetAdaptor=this._register(new ke(this.editor,(()=>(this._editorObs.forceUpdate(),this.model.get()?.selectedInlineCompletion.get()?.toSingleTextEdit(void 0))),(e=>this._editorObs.forceUpdate((t=>{this.model.get()?.handleSuggestAccepted(e)}))))),this._suggestWidgetSelectedItem=(0,r.y0)(this,(e=>this._suggestWidgetAdaptor.onDidSelectedItemChange((()=>{this._editorObs.forceUpdate((t=>e(void 0)))}))),(()=>this._suggestWidgetAdaptor.selectedItem)),this._enabledInConfig=(0,r.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(62).enabled)),this._isScreenReaderEnabled=(0,r.y0)(this,this._accessibilityService.onDidChangeScreenReaderOptimized,(()=>this._accessibilityService.isScreenReaderOptimized())),this._editorDictationInProgress=(0,r.y0)(this,this._contextKeyService.onDidChangeContext,(()=>!0===this._contextKeyService.getContext(this.editor.getDomNode()).getValue("editorDictation.inProgress"))),this._enabled=(0,r.un)(this,(e=>this._enabledInConfig.read(e)&&(!this._isScreenReaderEnabled.read(e)||!this._editorDictationInProgress.read(e)))),this._debounceValue=this._debounceService.for(this._languageFeaturesService.inlineCompletionsProvider,"InlineCompletionsDebounce",{min:50,max:50}),this.model=(0,m.a0)(this,(e=>{if(this._editorObs.isReadonly.read(e))return;const t=this._editorObs.model.read(e);if(!t)return;return this._instantiationService.createInstance(Se,t,this._suggestWidgetSelectedItem,this._editorObs.versionId,this._positions,this._debounceValue,(0,r.y0)(this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(119).preview)),(0,r.y0)(this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(119).previewMode)),(0,r.y0)(this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(62).mode)),this._enabled)})).recomputeInitiallyAndOnChange(this._store),this._ghostTexts=(0,r.un)(this,(e=>{const t=this.model.read(e);return t?.ghostTexts.read(e)??[]})),this._stablizedGhostTexts=function(e,t){const i=(0,r.FY)("result",[]),s=[];return t.add((0,r.fm)((t=>{const n=e.read(t);(0,r.Rn)((e=>{if(n.length!==s.length){s.length=n.length;for(let e=0;et.set(n[i],e)))}))}))),i}(this._ghostTexts,this._store),this._ghostTextWidgets=(0,f.Rl)(this,this._stablizedGhostTexts,((e,t)=>t.add(this._instantiationService.createInstance(B,this.editor,{ghostText:e,minReservedLineCount:(0,r.lk)(0),targetTextModel:this.model.map((e=>e?.textModel))})))).recomputeInitiallyAndOnChange(this._store),this._playAccessibilitySignal=(0,r.Yd)(this),this._fontFamily=(0,r.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(62).fontFamily)),this._register(new c.p(this._contextKeyService,this.model)),this._register((0,C.jD)(this._editorObs.onDidType,((e,t)=>{this._enabled.get()&&this.model.get()?.trigger()}))),this._register(this._commandService.onDidExecuteCommand((t=>{new Set([v.Yh.Tab.id,v.Yh.DeleteLeft.id,v.Yh.DeleteRight.id,l.Wt,"acceptSelectedSuggestion"]).has(t.commandId)&&e.hasTextFocus()&&this._enabled.get()&&this._editorObs.forceUpdate((e=>{this.model.get()?.trigger(e)}))}))),this._register((0,C.jD)(this._editorObs.selections,((e,t)=>{t.some((e=>3===e.reason||"api"===e.source))&&this.model.get()?.stop()}))),this._register(this.editor.onDidBlurEditorWidget((()=>{this._contextKeyService.getContextKeyValue("accessibleViewIsShown")||this._configurationService.getValue("editor.inlineSuggest.keepOnBlur")||e.getOption(62).keepOnBlur||z.bo.dropDownVisible||(0,r.Rn)((e=>{this.model.get()?.stop(e)}))}))),this._register((0,r.fm)((e=>{const t=this.model.read(e)?.state.read(e);t?.suggestItem?t.primaryGhostText.lineCount>=2&&this._suggestWidgetAdaptor.forceRenderingAbove():this._suggestWidgetAdaptor.stopForceRenderingAbove()}))),this._register((0,d.s)((()=>{this._suggestWidgetAdaptor.stopForceRenderingAbove()})));const y=(0,f.ZX)(this,((e,t)=>{const i=this.model.read(e),s=i?.state.read(e);return this._suggestWidgetSelectedItem.get()?t:s?.inlineCompletion?.semanticId}));this._register((0,C.Qg)((0,r.un)((e=>(this._playAccessibilitySignal.read(e),y.read(e),{}))),(async(e,t,i)=>{const s=this.model.get(),n=s?.state.get();if(!n||!s)return;const o=s.textModel.getLineContent(n.primaryGhostText.lineNumber);await(0,g.wR)(50,(0,p.bs)(i)),await(0,r.oJ)(this._suggestWidgetSelectedItem,_.b0,(()=>!1),(0,p.bs)(i)),await this._accessibilitySignalService.playSignal(De.Rh.inlineSuggestion),this.editor.getOption(8)&&this._provideScreenReaderUpdate(n.primaryGhostText.renderForScreenReader(o))}))),this._register(new z.Pm(this.editor,this.model,this._instantiationService)),this._register(function(e){const t=new d.Cm,i=t.add((0,h.jh)());return t.add((0,r.fm)((t=>{i.setStyle(e.read(t))}))),t}((0,r.un)((e=>{const t=this._fontFamily.read(e);return""===t||"default"===t?"":`\n.monaco-editor .ghost-text-decoration,\n.monaco-editor .ghost-text-decoration-preview,\n.monaco-editor .ghost-text {\n\tfont-family: ${t};\n}`})))),this._register(this._configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration("accessibility.verbosity.inlineCompletions")&&this.editor.updateOptions({inlineCompletionsAccessibilityVerbose:this._configurationService.getValue("accessibility.verbosity.inlineCompletions")})}))),this.editor.updateOptions({inlineCompletionsAccessibilityVerbose:this._configurationService.getValue("accessibility.verbosity.inlineCompletions")})}playAccessibilitySignal(e){this._playAccessibilitySignal.trigger(e)}_provideScreenReaderUpdate(e){const t=this._contextKeyService.getContextKeyValue("accessibleViewIsShown"),i=this._keybindingService.lookupKeybinding("editor.action.accessibleView");let s;!t&&i&&this.editor.getOption(150)&&(s=(0,Ie.kg)("showAccessibleViewHint","Inspect this in the accessible view ({0})",i.getAriaLabel())),(0,u.xE)(s?e+", "+s:e)}shouldShowHoverAt(e){const t=this.model.get()?.primaryGhostText.get();return!!t&&t.parts.some((i=>e.containsPosition(new b.y(t.lineNumber,i.column))))}shouldShowHoverAtViewZone(e){return this._ghostTextWidgets.get()[0]?.ownsViewZone(e)??!1}};Be=Ne=Ue([He(1,Ce._Y),He(2,Pe.fN),He(3,Me.pG),He(4,ve.d),He(5,E.ILanguageFeatureDebounceService),He(6,S.ILanguageFeaturesService),He(7,De.Nt),He(8,Fe.b),He(9,Oe.j)],Be);var We=i(48116),Ve=i(27195);class ze extends s.ks{static{this.ID=l.PA}constructor(){super({id:ze.ID,label:Ie.kg("action.inlineSuggest.showNext","Show Next Inline Suggestion"),alias:"Show Next Inline Suggestion",precondition:Pe.M$.and(a.R.writable,c.p.inlineSuggestionVisible),kbOpts:{weight:100,primary:606}})}async run(e,t){const i=Be.get(t);i?.model.get()?.next()}}class Ge extends s.ks{static{this.ID=l.Vl}constructor(){super({id:Ge.ID,label:Ie.kg("action.inlineSuggest.showPrevious","Show Previous Inline Suggestion"),alias:"Show Previous Inline Suggestion",precondition:Pe.M$.and(a.R.writable,c.p.inlineSuggestionVisible),kbOpts:{weight:100,primary:604}})}async run(e,t){const i=Be.get(t);i?.model.get()?.previous()}}class je extends s.ks{constructor(){super({id:"editor.action.inlineSuggest.trigger",label:Ie.kg("action.inlineSuggest.trigger","Trigger Inline Suggestion"),alias:"Trigger Inline Suggestion",precondition:a.R.writable})}async run(e,t){const i=Be.get(t);await(0,o.fL)((async e=>{await(i?.model.get()?.triggerExplicitly(e)),i?.playAccessibilitySignal(e)}))}}class Ke extends s.ks{constructor(){super({id:"editor.action.inlineSuggest.acceptNextWord",label:Ie.kg("action.inlineSuggest.acceptNextWord","Accept Next Word Of Inline Suggestion"),alias:"Accept Next Word Of Inline Suggestion",precondition:Pe.M$.and(a.R.writable,c.p.inlineSuggestionVisible),kbOpts:{weight:101,primary:2065,kbExpr:Pe.M$.and(a.R.writable,c.p.inlineSuggestionVisible)},menuOpts:[{menuId:Ve.D8.InlineSuggestionToolbar,title:Ie.kg("acceptWord","Accept Word"),group:"primary",order:2}]})}async run(e,t){const i=Be.get(t);await(i?.model.get()?.acceptNextWord(i.editor))}}class Ye extends s.ks{constructor(){super({id:"editor.action.inlineSuggest.acceptNextLine",label:Ie.kg("action.inlineSuggest.acceptNextLine","Accept Next Line Of Inline Suggestion"),alias:"Accept Next Line Of Inline Suggestion",precondition:Pe.M$.and(a.R.writable,c.p.inlineSuggestionVisible),kbOpts:{weight:101},menuOpts:[{menuId:Ve.D8.InlineSuggestionToolbar,title:Ie.kg("acceptLine","Accept Line"),group:"secondary",order:2}]})}async run(e,t){const i=Be.get(t);await(i?.model.get()?.acceptNextLine(i.editor))}}class qe extends s.ks{constructor(){super({id:l.Wt,label:Ie.kg("action.inlineSuggest.accept","Accept Inline Suggestion"),alias:"Accept Inline Suggestion",precondition:c.p.inlineSuggestionVisible,menuOpts:[{menuId:Ve.D8.InlineSuggestionToolbar,title:Ie.kg("accept","Accept"),group:"primary",order:1}],kbOpts:{primary:2,weight:200,kbExpr:Pe.M$.and(c.p.inlineSuggestionVisible,a.R.tabMovesFocus.toNegated(),c.p.inlineSuggestionHasIndentationLessThanTabSize,We.ob.Visible.toNegated(),a.R.hoverFocused.toNegated())}})}async run(e,t){const i=Be.get(t);i&&(i.model.get()?.accept(i.editor),i.editor.focus())}}class $e extends s.ks{static{this.ID="editor.action.inlineSuggest.hide"}constructor(){super({id:$e.ID,label:Ie.kg("action.inlineSuggest.hide","Hide Inline Suggestion"),alias:"Hide Inline Suggestion",precondition:c.p.inlineSuggestionVisible,kbOpts:{weight:100,primary:9}})}async run(e,t){const i=Be.get(t);(0,r.Rn)((e=>{i?.model.get()?.stop(e)}))}}class Qe extends Ve.L{static{this.ID="editor.action.inlineSuggest.toggleAlwaysShowToolbar"}constructor(){super({id:Qe.ID,title:Ie.kg("action.inlineSuggest.alwaysShowToolbar","Always Show Toolbar"),f1:!1,precondition:void 0,menu:[{id:Ve.D8.InlineSuggestionToolbar,group:"secondary",order:10}],toggled:Pe.M$.equals("config.editor.inlineSuggest.showToolbar","always")})}async run(e,t){const i=e.get(Me.pG),s="always"===i.getValue("editor.inlineSuggest.showToolbar")?"onHover":"always";i.updateValue("editor.inlineSuggest.showToolbar",s)}}var Xe=i(16980),Ze=i(20492),Je=i(49099),et=i(90651),tt=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},it=function(e,t){return function(i,s){t(i,s,e)}};class st{constructor(e,t,i){this.owner=e,this.range=t,this.controller=i}isValidForHoverAnchor(e){return 1===e.type&&this.range.startColumn<=e.range.startColumn&&this.range.endColumn>=e.range.endColumn}}let nt=class{constructor(e,t,i,s,n,r){this._editor=e,this._languageService=t,this._openerService=i,this.accessibilityService=s,this._instantiationService=n,this._telemetryService=r,this.hoverOrdinal=4}suggestHoverAnchor(e){const t=Be.get(this._editor);if(!t)return null;const i=e.target;if(8===i.type){const s=i.detail;if(t.shouldShowHoverAtViewZone(s.viewZoneId))return new n.mm(1e3,this,x.Q.fromPositions(this._editor.getModel().validatePosition(s.positionBefore||s.position)),e.event.posx,e.event.posy,!1)}if(7===i.type&&t.shouldShowHoverAt(i.range))return new n.mm(1e3,this,i.range,e.event.posx,e.event.posy,!1);if(6===i.type){if(i.detail.mightBeForeignElement&&t.shouldShowHoverAt(i.range))return new n.mm(1e3,this,i.range,e.event.posx,e.event.posy,!1)}return null}computeSync(e,t){if("onHover"!==this._editor.getOption(62).showToolbar)return[];const i=Be.get(this._editor);return i&&i.shouldShowHoverAt(e.range)?[new st(this,e.range,i)]:[]}renderHoverParts(e,t){const i=new d.Cm,s=t[0];this._telemetryService.publicLog2("inlineCompletionHover.shown"),this.accessibilityService.isScreenReaderOptimized()&&!this._editor.getOption(8)&&i.add(this.renderScreenReaderText(e,s));const o=s.controller.model.get(),a=this._instantiationService.createInstance(z.bo,this._editor,!1,(0,r.lk)(null),o.selectedInlineCompletionIndex,o.inlineCompletionsCount,o.activeCommands),l=a.getDomNode();e.fragment.appendChild(l),o.triggerExplicitly(),i.add(a);const c={hoverPart:s,hoverElement:l,dispose(){i.dispose()}};return new n.Ke([c])}renderScreenReaderText(e,t){const i=new d.Cm,s=h.$,n=s("div.hover-row.markdown-hover"),o=h.BC(n,s("div.hover-contents",{"aria-live":"assertive"})),a=i.add(new Ze.T({editor:this._editor},this._languageService,this._openerService));return i.add((0,r.fm)((s=>{const n=t.controller.model.read(s)?.primaryGhostText.read(s);if(n){const t=this._editor.getModel().getLineContent(n.lineNumber);(t=>{i.add(a.onDidRenderAsync((()=>{o.className="hover-contents code-hover-contents",e.onContentsChanged()})));const s=Ie.kg("inlineSuggestionFollows","Suggestion:"),n=i.add(a.render((new Xe.Bc).appendText(s).appendCodeblock("text",t)));o.replaceChildren(n.element)})(n.renderForScreenReader(t))}else h.Ln(o)}))),e.fragment.appendChild(n),i}};nt=tt([it(1,A.L),it(2,Je.C),it(3,Oe.j),it(4,Ce._Y),it(5,et.k)],nt);var rt=i(96282);(0,s.HW)(Be.ID,Be,3),(0,s.Fl)(je),(0,s.Fl)(ze),(0,s.Fl)(Ge),(0,s.Fl)(Ke),(0,s.Fl)(Ye),(0,s.Fl)(qe),(0,s.Fl)($e),(0,Ve.ug)(Qe),n.B2.register(nt),rt.Z.register(new class{})},92674:(e,t,i)=>{"use strict";i.d(t,{AL:()=>d,Vs:()=>h,x9:()=>u,xD:()=>l,yP:()=>c});var s=i(25890),n=i(91508),r=i(83069),o=i(36677),a=i(75295);class l{constructor(e,t){this.lineNumber=e,this.parts=t}equals(e){return this.lineNumber===e.lineNumber&&this.parts.length===e.parts.length&&this.parts.every(((t,i)=>t.equals(e.parts[i])))}renderForScreenReader(e){if(0===this.parts.length)return"";const t=this.parts[this.parts.length-1],i=e.substr(0,t.column-1);return new a.mF([...this.parts.map((e=>new a.WR(o.Q.fromPositions(new r.y(1,e.column)),e.lines.join("\n"))))]).applyToString(i).substring(this.parts[0].column-1)}isEmpty(){return this.parts.every((e=>0===e.lines.length))}get lineCount(){return 1+this.parts.reduce(((e,t)=>e+t.lines.length-1),0)}}class c{constructor(e,t,i){this.column=e,this.text=t,this.preview=i,this.lines=(0,n.uz)(this.text)}equals(e){return this.column===e.column&&this.lines.length===e.lines.length&&this.lines.every(((t,i)=>t===e.lines[i]))}}class h{constructor(e,t,i,s=0){this.lineNumber=e,this.columnRange=t,this.text=i,this.additionalReservedLineCount=s,this.parts=[new c(this.columnRange.endColumnExclusive,this.text,!1)],this.newLines=(0,n.uz)(this.text)}renderForScreenReader(e){return this.newLines.join("\n")}get lineCount(){return this.newLines.length}isEmpty(){return this.parts.every((e=>0===e.lines.length))}equals(e){return this.lineNumber===e.lineNumber&&this.columnRange.equals(e.columnRange)&&this.newLines.length===e.newLines.length&&this.newLines.every(((t,i)=>t===e.newLines[i]))&&this.additionalReservedLineCount===e.additionalReservedLineCount}}function d(e,t){return(0,s.aI)(e,t,u)}function u(e,t){return e===t||!(!e||!t)&&((e instanceof l&&t instanceof l||e instanceof h&&t instanceof h)&&e.equals(t))}},20940:(e,t,i)=>{"use strict";i.d(t,{Yk:()=>C});var s=i(66782),n=i(90766),r=i(18447),o=i(74320),a=i(64383),l=i(83069),c=i(36677),h=i(93630),d=i(19131),u=i(19562),g=i(32956),p=i(51934);class m{constructor(e){this.lines=e,this.tokenization={getLineTokens:e=>this.lines[e-1]}}getLineCount(){return this.lines.length}getLineLength(e){return this.lines[e-1].getLineContent().length}}var f=i(75295),_=i(73401),v=i(29319);async function C(e,t,i,s,h=r.XO.None,d){const u=t instanceof l.y?function(e,t){const i=t.getWordAtPosition(e),s=t.getLineMaxColumn(e.lineNumber);return i?new c.Q(e.lineNumber,i.startColumn,e.lineNumber,s):c.Q.fromPositions(e,e.with(void 0,s))}(t,i):t,g=e.all(i),p=new o.db;for(const n of g)n.groupId&&p.add(n.groupId,n);function m(e){if(!e.yieldsToGroupIds)return[];const t=[];for(const i of e.yieldsToGroupIds||[]){const e=p.get(i);for(const i of e)t.push(i)}return t}const f=new Map,_=new Set;function v(e,t){if(t=[...t,e],_.has(e))return t;_.add(e);try{const i=m(e);for(const e of i){const i=v(e,t);if(i)return i}}finally{_.delete(e)}}function C(e){const r=f.get(e);if(r)return r;const o=v(e,[]);o&&(0,a.M_)(new Error(`Inline completions: cyclic yield-to dependency detected. Path: ${o.map((e=>e.toString?e.toString():""+e)).join(" -> ")}`));const c=new n.Zv;return f.set(e,c.p),(async()=>{if(!o){const t=m(e);for(const e of t){const t=await C(e);if(t&&t.items.length>0)return}}try{if(t instanceof l.y){return await e.provideInlineCompletions(i,t,s,h)}return await(e.provideInlineEdits?.(i,t,s,h))}catch(n){return void(0,a.M_)(n)}})().then((e=>c.complete(e)),(e=>c.error(e))),c.p}const y=await Promise.all(g.map((async e=>({provider:e,completions:await C(e)})))),w=new Map,L=[];for(const n of y){const e=n.completions;if(!e)continue;const t=new E(e,n.provider);L.push(t);for(const s of e.items){const e=S.from(s,t,u,i,d);w.set(e.hash(),e)}}return new b(Array.from(w.values()),new Set(w.keys()),L)}class b{constructor(e,t,i){this.completions=e,this.hashs=t,this.providerResults=i}has(e){return this.hashs.has(e.hash())}dispose(){for(const e of this.providerResults)e.removeRef()}}class E{constructor(e,t){this.inlineCompletions=e,this.provider=t,this.refCount=1}addRef(){this.refCount++}removeRef(){this.refCount--,0===this.refCount&&this.provider.freeInlineCompletions(this.inlineCompletions)}}class S{static from(e,t,i,n,r){let o,a,l=e.range?c.Q.lift(e.range):i;if("string"===typeof e.insertText){if(o=e.insertText,r&&e.completeBracketPairs){o=y(o,l.getStartPosition(),n,r);const t=o.length-e.insertText.length;0!==t&&(l=new c.Q(l.startLineNumber,l.startColumn,l.endLineNumber,l.endColumn+t))}a=void 0}else if("snippet"in e.insertText){const t=e.insertText.snippet.length;if(r&&e.completeBracketPairs){e.insertText.snippet=y(e.insertText.snippet,l.getStartPosition(),n,r);const i=e.insertText.snippet.length-t;0!==i&&(l=new c.Q(l.startLineNumber,l.startColumn,l.endLineNumber,l.endColumn+i))}const i=(new v.fr).parse(e.insertText.snippet);1===i.children.length&&i.children[0]instanceof v.EY?(o=i.children[0].value,a=void 0):(o=i.toString(),a={snippet:e.insertText.snippet,range:l})}else(0,s.xb)(e.insertText);return new S(o,e.command,l,o,a,e.additionalTextEdits||(0,_.zk)(),e,t)}constructor(e,t,i,s,n,r,o,a){this.filterText=e,this.command=t,this.range=i,this.insertText=s,this.snippetInfo=n,this.additionalTextEdits=r,this.sourceInlineCompletion=o,this.source=a,s=(e=e.replace(/\r\n|\r/g,"\n")).replace(/\r\n|\r/g,"\n")}withRange(e){return new S(this.filterText,this.command,e,this.insertText,this.snippetInfo,this.additionalTextEdits,this.sourceInlineCompletion,this.source)}hash(){return JSON.stringify({insertText:this.insertText,range:this.range.toString()})}toSingleTextEdit(){return new f.WR(this.range,this.insertText)}}function y(e,t,i,s){const n=i.getLineContent(t.lineNumber).substring(0,t.column-1)+e,r=i.tokenization.tokenizeLineWithEdit(t,n.length-(t.column-1),e),o=r?.sliceAndInflate(t.column-1,n.length,0);if(!o)return e;const a=function(e,t){const i=new g.Mg,s=new h.Z(i,(e=>t.getLanguageConfiguration(e))),n=new p.tk(new m([e]),s),r=(0,u.T)(n,[],void 0,!0);let o="";const a=e.getLineContent();return function e(t,i){if(2===t.kind)if(e(t.openingBracket,i),i=(0,d.QB)(i,t.openingBracket.length),t.child&&(e(t.child,i),i=(0,d.QB)(i,t.child.length)),t.closingBracket)e(t.closingBracket,i),i=(0,d.QB)(i,t.closingBracket.length);else{const e=s.getSingleLanguageBracketTokens(t.openingBracket.languageId).findClosingTokenText(t.openingBracket.bracketIds);o+=e}else if(3===t.kind);else if(0===t.kind||1===t.kind)o+=a.substring((0,d.sS)(i),(0,d.sS)((0,d.QB)(i,t.length)));else if(4===t.kind)for(const s of t.children)e(s,i),i=(0,d.QB)(i,s.length)}(r,d.Vp),o}(o,s);return a}},73401:(e,t,i)=>{"use strict";i.d(t,{GM:()=>h,OA:()=>u,pY:()=>d,tN:()=>g,zk:()=>c});var s=i(64383),n=i(5662),r=i(31308),o=i(83069),a=i(36677);const l=[];function c(){return l}class h{constructor(e,t){if(this.startColumn=e,this.endColumnExclusive=t,e>t)throw new s.D7(`startColumn ${e} cannot be after endColumnExclusive ${t}`)}toRange(e){return new a.Q(e,this.startColumn,e,this.endColumnExclusive)}equals(e){return this.startColumn===e.startColumn&&this.endColumnExclusive===e.endColumnExclusive}}function d(e,t){const i=new n.Cm,s=e.createDecorationsCollection();return i.add((0,r.zL)({debugName:()=>`Apply decorations from ${t.debugName}`},(e=>{const i=t.read(e);s.set(i)}))),i.add({dispose:()=>{s.clear()}}),i}function u(e,t){return new o.y(e.lineNumber+t.lineNumber-1,1===t.lineNumber?e.column+t.column-1:t.column)}function g(e,t){return new o.y(e.lineNumber-t.lineNumber+1,e.lineNumber-t.lineNumber===0?e.column-t.column+1:e.column)}},58145:(e,t,i)=>{"use strict";var s=i(31450),n=i(60002);var r=i(5662),o=i(31308),a=i(7085),l=i(83069),c=i(36677),h=i(10154),d=i(16223),u=i(25521),g=i(73401),p=i(10691),m=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},f=function(e,t){return function(i,s){t(i,s,e)}};const _="inline-edit";let v=class extends r.jG{constructor(e,t,i){super(),this.editor=e,this.model=t,this.languageService=i,this.isDisposed=(0,o.FY)(this,!1),this.currentTextModel=(0,o.y0)(this,this.editor.onDidChangeModel,(()=>this.editor.getModel())),this.uiState=(0,o.un)(this,(e=>{if(this.isDisposed.read(e))return;const t=this.currentTextModel.read(e);if(t!==this.model.targetTextModel.read(e))return;const i=this.model.ghostText.read(e);if(!i)return;let s=this.model.range?.read(e);s&&s.startLineNumber===s.endLineNumber&&s.startColumn===s.endColumn&&(s=void 0);const n=(!s||s.startLineNumber===s.endLineNumber)&&1===i.parts.length&&1===i.parts[0].lines.length,r=1===i.parts.length&&i.parts[0].lines.every((e=>0===e.length)),o=[],a=[];function l(e,t){if(a.length>0){const i=a[a.length-1];t&&i.decorations.push(new u.d(i.content.length+1,i.content.length+1+e[0].length,t,0)),i.content+=e[0],e=e.slice(1)}for(const i of e)a.push({content:i,decorations:t?[new u.d(1,i.length+1,t,0)]:[]})}const c=t.getLineContent(i.lineNumber);let h,d=0;if(!r&&(n||!s)){for(const e of i.parts){let t=e.lines;s&&!n&&(l(t,_),t=[]),void 0===h?(o.push({column:e.column,text:t[0],preview:e.preview}),t=t.slice(1)):l([c.substring(d,e.column-1)],void 0),t.length>0&&(l(t,_),void 0===h&&e.column<=c.length&&(h=e.column)),d=e.column-1}void 0!==h&&l([c.substring(d)],void 0)}const p=void 0!==h?new g.GM(h,c.length+1):void 0,m=n||!s?i.lineNumber:s.endLineNumber-1;return{inlineTexts:o,additionalLines:a,hiddenRange:p,lineNumber:m,additionalReservedLineCount:this.model.minReservedLineCount.read(e),targetTextModel:t,range:s,isSingleLine:n,isPureRemove:r}})),this.decorations=(0,o.un)(this,(e=>{const t=this.uiState.read(e);if(!t)return[];const i=[];if(t.hiddenRange&&i.push({range:t.hiddenRange.toRange(t.lineNumber),options:{inlineClassName:"inline-edit-hidden",description:"inline-edit-hidden"}}),t.range){const e=[];if(t.isSingleLine)e.push(t.range);else if(!t.isPureRemove){const i=t.range.endLineNumber-t.range.startLineNumber;for(let s=0;s{this.isDisposed.set(!0,void 0)}))),this._register((0,g.pY)(this.editor,this.decorations))}};v=m([f(2,h.L)],v);var C,b=i(32848),E=i(63591),S=i(62083),y=i(56942),w=i(18447),L=i(92674),R=i(50091),T=i(8597),x=i(47625),k=i(36921),A=i(25890),N=i(98067),I=i(57629),O=i(65644),D=i(27195),M=i(47508),P=i(98031),F=i(90651),U=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},H=function(e,t){return function(i,s){t(i,s,e)}};let B=class extends r.jG{constructor(e,t,i){super(),this.editor=e,this.model=t,this.instantiationService=i,this.alwaysShowToolbar=(0,o.y0)(this,this.editor.onDidChangeConfiguration,(()=>"always"===this.editor.getOption(63).showToolbar)),this.sessionPosition=void 0,this.position=(0,o.un)(this,(e=>{const t=this.model.read(e)?.model.ghostText.read(e);if(!this.alwaysShowToolbar.read(e)||!t||0===t.parts.length)return this.sessionPosition=void 0,null;const i=t.parts[0].column;this.sessionPosition&&this.sessionPosition.lineNumber!==t.lineNumber&&(this.sessionPosition=void 0);const s=new l.y(t.lineNumber,Math.min(i,this.sessionPosition?.column??Number.MAX_SAFE_INTEGER));return this.sessionPosition=s,s})),this._register((0,o.yC)(((t,i)=>{if(!this.model.read(t)||!this.alwaysShowToolbar.read(t))return;const s=i.add(this.instantiationService.createInstance(W,this.editor,!0,this.position));e.addContentWidget(s),i.add((0,r.s)((()=>e.removeContentWidget(s))))})))}};B=U([H(2,E._Y)],B);let W=class extends r.jG{static{C=this}static{this._dropDownVisible=!1}static{this.id=0}constructor(e,t,i,s,n,r){super(),this.editor=e,this.withBorder=t,this._position=i,this._contextKeyService=n,this._menuService=r,this.id="InlineEditHintsContentWidget"+C.id++,this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this.nodes=(0,T.h)("div.inlineEditHints",{className:this.withBorder?".withBorder":""},[(0,T.h)("div@toolBar")]),this.inlineCompletionsActionsMenus=this._register(this._menuService.createMenu(D.D8.InlineEditActions,this._contextKeyService)),this.toolBar=this._register(s.createInstance(z,this.nodes.toolBar,this.editor,D.D8.InlineEditToolbar,{menuOptions:{renderShortTitle:!0},toolbarOptions:{primaryGroup:e=>e.startsWith("primary")},actionViewItemProvider:(e,t)=>{if(e instanceof D.Xe)return s.createInstance(V,e,void 0)},telemetrySource:"InlineEditToolbar"})),this._register(this.toolBar.onDidChangeDropdownVisibility((e=>{C._dropDownVisible=e}))),this._register((0,o.fm)((e=>{this._position.read(e),this.editor.layoutContentWidget(this)}))),this._register((0,o.fm)((e=>{const t=[];for(const[i,s]of this.inlineCompletionsActionsMenus.getActions())for(const e of s)e instanceof D.Xe&&t.push(e);t.length>0&&t.unshift(new k.wv),this.toolBar.setAdditionalSecondaryActions(t)})))}getId(){return this.id}getDomNode(){return this.nodes.root}getPosition(){return{position:this._position.get(),preference:[1,2],positionAffinity:3}}};W=C=U([H(3,E._Y),H(4,b.fN),H(5,D.ez)],W);class V extends I.oq{updateLabel(){const e=this._keybindingService.lookupKeybinding(this._action.id,this._contextKeyService);if(!e)return super.updateLabel();if(this.label){const t=(0,T.h)("div.keybinding").root;this._register(new x.x(t,N.OS,{disableTitle:!0,...x.l})).set(e),this.label.textContent=this._action.label,this.label.appendChild(t),this.label.classList.add("inlineEditStatusBarItemLabel")}}updateTooltip(){}}let z=class extends O.p{constructor(e,t,i,s,n,r,o,a,l,c){super(e,{resetMenu:i,...s},n,r,o,a,l,c),this.editor=t,this.menuId=i,this.options2=s,this.menuService=n,this.contextKeyService=r,this.menu=this._store.add(this.menuService.createMenu(this.menuId,this.contextKeyService,{emitEventsForSubmenuChanges:!0})),this.additionalActions=[],this.prependedPrimaryActions=[],this._store.add(this.menu.onDidChange((()=>this.updateToolbar()))),this._store.add(this.editor.onDidChangeCursorPosition((()=>this.updateToolbar()))),this.updateToolbar()}updateToolbar(){const e=[],t=[];(0,I.Ot)(this.menu,this.options2?.menuOptions,{primary:e,secondary:t},this.options2?.toolbarOptions?.primaryGroup,this.options2?.toolbarOptions?.shouldInlineSubmenu,this.options2?.toolbarOptions?.useSeparatorsInPrimaryActions),t.push(...this.additionalActions),e.unshift(...this.prependedPrimaryActions),this.setActions(e,t)}setAdditionalSecondaryActions(e){(0,A.aI)(this.additionalActions,e,((e,t)=>e===t))||(this.additionalActions=e,this.updateToolbar())}};z=U([H(4,D.ez),H(5,b.fN),H(6,M.Z),H(7,P.b),H(8,R.d),H(9,F.k)],z);var G,j,K=i(84001),Y=i(64383),q=i(87958),$=i(79400),Q=i(38844),X=i(29163),Z=i(94746),J=i(83941),ee=i(87289),te=i(23750),ie=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},se=function(e,t){return function(i,s){t(i,s,e)}};function ne(e){const t=e[0].match(/^\s*/)?.[0]??"",i=t.length;return{text:e.map((e=>e.replace(new RegExp("^"+t),""))),shift:i}}let re=class extends r.jG{static{G=this}static{this._modelId=0}static _createUniqueUri(){return $.r.from({scheme:"inline-edit-widget",path:(new Date).toString()+String(G._modelId++)})}constructor(e,t,i,s,n){super(),this._editor=e,this._model=t,this._instantiationService=i,this._diffProviderFactoryService=s,this._modelService=n,this._position=(0,o.un)(this,(e=>{const t=this._model.read(e);if(!t||0===t.text.length)return null;if(t.range.startLineNumber===t.range.endLineNumber&&(t.range.startColumn!==t.range.endColumn||1!==t.range.startColumn))return null;const i=this._editor.getModel();if(!i)return null;const s=Array.from(function*(e,t,i=1){void 0===t&&([t,e]=[e,0]);for(let s=e;si.getLineLastNonWhitespaceColumn(e))),r=Math.max(...n),o=s[n.indexOf(r)],a=new l.y(o,r);return{top:t.range.startLineNumber,left:a}})),this._text=(0,o.un)(this,(e=>{const t=this._model.read(e);if(!t)return{text:"",shift:0};const i=ne(t.text.split("\n"));return{text:i.text.join("\n"),shift:i.shift}})),this._originalModel=(0,q.a0)((()=>this._modelService.createModel("",null,G._createUniqueUri()))).keepObserved(this._store),this._modifiedModel=(0,q.a0)((()=>this._modelService.createModel("",null,G._createUniqueUri()))).keepObserved(this._store),this._diff=(0,o.un)(this,(e=>this._diffPromise.read(e)?.promiseResult.read(e)?.data)),this._diffPromise=(0,o.un)(this,(e=>{const t=this._model.read(e);if(!t)return;const i=this._editor.getModel();if(!i)return;const s=ne(i.getValueInRange(t.range).split("\n")).text.join("\n"),n=ne(t.text.split("\n")).text.join("\n");this._originalModel.get().setValue(s),this._modifiedModel.get().setValue(n);const r=this._diffProviderFactoryService.createDiffProvider({diffAlgorithm:"advanced"});return o.BK.fromFn((async()=>{const e=await r.computeDiff(this._originalModel.get(),this._modifiedModel.get(),{computeMoves:!1,ignoreTrimWhitespace:!1,maxComputationTimeMs:1e3},w.XO.None);if(!e.identical)return e.changes}))})),this._register((0,o.yC)(((t,i)=>{if(!this._model.read(t))return;if(null===this._position.get())return;const s=i.add(this._instantiationService.createInstance(oe,this._editor,this._position,this._text.map((e=>e.text)),this._text.map((e=>e.shift)),this._diff));e.addOverlayWidget(s),i.add((0,r.s)((()=>e.removeOverlayWidget(s))))})))}};re=G=ie([se(2,E._Y),se(3,Z.Hg),se(4,te.IModelService)],re);let oe=class extends r.jG{static{j=this}static{this.id=0}constructor(e,t,i,s,n,r){super(),this._editor=e,this._position=t,this._text=i,this._shift=s,this._diff=n,this._instantiationService=r,this.id="InlineEditSideBySideContentWidget"+j.id++,this.allowEditorOverflow=!1,this._nodes=(0,T.$)("div.inlineEditSideBySide",void 0),this._scrollChanged=(0,o.yQ)("editor.onDidScrollChange",this._editor.onDidScrollChange),this._previewEditor=this._register(this._instantiationService.createInstance(X.t,this._nodes,{glyphMargin:!1,lineNumbers:"off",minimap:{enabled:!1},guides:{indentation:!1,bracketPairs:!1,bracketPairsHorizontal:!1,highlightActiveIndentation:!1},folding:!1,selectOnLineNumbers:!1,selectionHighlight:!1,columnSelection:!1,overviewRulerBorder:!1,overviewRulerLanes:0,lineDecorationsWidth:0,lineNumbersMinChars:0,scrollbar:{vertical:"hidden",horizontal:"hidden",alwaysConsumeMouseWheel:!1,handleMouseWheel:!1},readOnly:!0,wordWrap:"off",wordWrapOverride1:"off",wordWrapOverride2:"off",wrappingIndent:"none",wrappingStrategy:void 0},{contributions:[],isSimpleWidget:!0},this._editor)),this._previewEditorObs=(0,Q.Ud)(this._previewEditor),this._editorObs=(0,Q.Ud)(this._editor),this._previewTextModel=this._register(this._instantiationService.createInstance(ee.Bz,"",this._editor.getModel()?.getLanguageId()??J.vH,ee.Bz.DEFAULT_CREATION_OPTIONS,null)),this._setText=(0,o.un)((e=>{const t=this._text.read(e);t&&this._previewTextModel.setValue(t)})).recomputeInitiallyAndOnChange(this._store),this._decorations=(0,o.un)(this,(e=>{this._setText.read(e);const t=this._position.read(e);if(!t)return{org:[],mod:[]};const i=this._diff.read(e);if(!i)return{org:[],mod:[]};const s=[],n=[];if(1===i.length&&i[0].innerChanges[0].modifiedRange.equalsRange(this._previewTextModel.getFullModelRange()))return{org:[],mod:[]};const r=this._shift.get(),o=e=>new c.Q(e.startLineNumber+t.top-1,e.startColumn+r,e.endLineNumber+t.top-1,e.endColumn+r);for(const a of i)if(a.original.isEmpty||s.push({range:o(a.original.toInclusiveRange()),options:p.Ob}),a.modified.isEmpty||n.push({range:a.modified.toInclusiveRange(),options:p.Kl}),a.modified.isEmpty||a.original.isEmpty)a.original.isEmpty||s.push({range:o(a.original.toInclusiveRange()),options:p.KL}),a.modified.isEmpty||n.push({range:a.modified.toInclusiveRange(),options:p.Ou});else for(const e of a.innerChanges||[])a.original.contains(e.originalRange.startLineNumber)&&s.push({range:o(e.originalRange),options:e.originalRange.isEmpty()?p.wp:p.Zb}),a.modified.contains(e.modifiedRange.startLineNumber)&&n.push({range:e.modifiedRange,options:e.modifiedRange.isEmpty()?p.GM:p.bk});return{org:s,mod:n}})),this._originalDecorations=(0,o.un)(this,(e=>this._decorations.read(e).org)),this._modifiedDecorations=(0,o.un)(this,(e=>this._decorations.read(e).mod)),this._previewEditor.setModel(this._previewTextModel),this._register(this._editorObs.setDecorations(this._originalDecorations)),this._register(this._previewEditorObs.setDecorations(this._modifiedDecorations)),this._register((0,o.fm)((e=>{const t=this._previewEditorObs.contentWidth.read(e),i=this._text.read(e).split("\n").length-1,s=this._editor.getOption(67)*i;t<=0||this._previewEditor.layout({height:s,width:t})}))),this._register((0,o.fm)((e=>{this._position.read(e),this._editor.layoutOverlayWidget(this)}))),this._register((0,o.fm)((e=>{this._scrollChanged.read(e);this._position.read(e)&&this._editor.layoutOverlayWidget(this)})))}getId(){return this.id}getDomNode(){return this._nodes}getPosition(){const e=this._position.get();if(!e)return null;const t=this._editor.getLayoutInfo(),i=this._editor.getScrolledVisiblePosition(new l.y(e.top,1));if(!i)return null;const s=i.top-1,n=this._editor.getOffsetForColumn(e.left.lineNumber,e.left.column);return{preference:{left:t.contentLeft+n+10,top:s}}}};oe=j=ie([se(5,E._Y)],oe);var ae,le=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ce=function(e,t){return function(i,s){t(i,s,e)}};let he=class extends r.jG{static{ae=this}static{this.ID="editor.contrib.inlineEditController"}static{this.inlineEditVisibleKey="inlineEditVisible"}static{this.inlineEditVisibleContext=new b.N1(this.inlineEditVisibleKey,!1)}static{this.cursorAtInlineEditKey="cursorAtInlineEdit"}static{this.cursorAtInlineEditContext=new b.N1(this.cursorAtInlineEditKey,!1)}static get(e){return e.getContribution(ae.ID)}constructor(e,t,i,s,n,r,a,l){super(),this.editor=e,this.instantiationService=t,this.contextKeyService=i,this.languageFeaturesService=s,this._commandService=n,this._configurationService=r,this._diffProviderFactoryService=a,this._modelService=l,this._isVisibleContext=ae.inlineEditVisibleContext.bindTo(this.contextKeyService),this._isCursorAtInlineEditContext=ae.cursorAtInlineEditContext.bindTo(this.contextKeyService),this._currentEdit=(0,o.FY)(this,void 0),this._currentWidget=(0,q.a0)(this._currentEdit,(e=>{const t=this._currentEdit.read(e);if(!t)return;const i=t.range.endLineNumber,s=t.range.endColumn,n=!t.text.endsWith("\n")||t.range.startLineNumber===t.range.endLineNumber&&t.range.startColumn===t.range.endColumn?t.text:t.text.slice(0,-1),r=new L.xD(i,[new L.yP(s,n,!1)]),a=t.range.startLineNumber===t.range.endLineNumber&&1===r.parts.length&&1===r.parts[0].lines.length,l=""===t.text;if(!a&&!l)return;return this.instantiationService.createInstance(v,this.editor,{ghostText:(0,o.lk)(r),minReservedLineCount:(0,o.lk)(0),targetTextModel:(0,o.lk)(this.editor.getModel()??void 0),range:(0,o.lk)(t.range)})})),this._isAccepting=(0,o.FY)(this,!1),this._enabled=(0,o.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(63).enabled)),this._fontFamily=(0,o.y0)(this,this.editor.onDidChangeConfiguration,(()=>this.editor.getOption(63).fontFamily));const c=(0,o.yQ)("InlineEditController.modelContentChangedSignal",e.onDidChangeModelContent);this._register((0,o.fm)((t=>{this._enabled.read(t)&&(c.read(t),this._isAccepting.read(t)||this.getInlineEdit(e,!0))})));const h=(0,o.y0)(this,e.onDidChangeCursorPosition,(()=>e.getPosition()));this._register((0,o.fm)((e=>{if(!this._enabled.read(e))return;const t=h.read(e);t&&this.checkCursorPosition(t)}))),this._register((0,o.fm)((t=>{const i=this._currentEdit.read(t);if(this._isCursorAtInlineEditContext.set(!1),!i)return void this._isVisibleContext.set(!1);this._isVisibleContext.set(!0);const s=e.getPosition();s&&this.checkCursorPosition(s)})));const d=(0,o.yQ)("InlineEditController.editorBlurSignal",e.onDidBlurEditorWidget);this._register((0,o.fm)((async t=>{this._enabled.read(t)&&(d.read(t),this._configurationService.getValue("editor.experimentalInlineEdit.keepOnBlur")||e.getOption(63).keepOnBlur||(this._currentRequestCts?.dispose(!0),this._currentRequestCts=void 0,await this.clear(!1)))})));const u=(0,o.yQ)("InlineEditController.editorFocusSignal",e.onDidFocusEditorText);this._register((0,o.fm)((t=>{this._enabled.read(t)&&(u.read(t),this.getInlineEdit(e,!0))})));const g=this._register((0,T.jh)());this._register((0,o.fm)((e=>{const t=this._fontFamily.read(e);g.setStyle(""===t||"default"===t?"":`\n.monaco-editor .inline-edit-decoration,\n.monaco-editor .inline-edit-decoration-preview,\n.monaco-editor .inline-edit {\n\tfont-family: ${t};\n}`)}))),this._register(new B(this.editor,this._currentWidget,this.instantiationService)),this._register(new re(this.editor,this._currentEdit,this.instantiationService,this._diffProviderFactoryService,this._modelService))}checkCursorPosition(e){if(!this._currentEdit)return void this._isCursorAtInlineEditContext.set(!1);const t=this._currentEdit.get();t?this._isCursorAtInlineEditContext.set(c.Q.containsPosition(t.range,e)):this._isCursorAtInlineEditContext.set(!1)}validateInlineEdit(e,t){if(t.text.includes("\n")&&t.range.startLineNumber!==t.range.endLineNumber&&t.range.startColumn!==t.range.endColumn){if(1!==t.range.startColumn)return!1;const i=t.range.endLineNumber;if(t.range.endColumn!==(e.getModel()?.getLineLength(i)??0)+1)return!1}return!0}async fetchInlineEdit(e,t){this._currentRequestCts&&this._currentRequestCts.dispose(!0);const i=e.getModel();if(!i)return;const s=i.getVersionId(),n=this.languageFeaturesService.inlineEditProvider.all(i);if(0===n.length)return;const r=n[0];this._currentRequestCts=new w.Qi;const o=this._currentRequestCts.token,a=t?S.sm.Automatic:S.sm.Invoke;var l,c;if(t&&await(l=50,c=o,new Promise((e=>{let t;const i=setTimeout((()=>{t&&t.dispose(),e()}),l);c&&(t=c.onCancellationRequested((()=>{clearTimeout(i),t&&t.dispose(),e()})))}))),o.isCancellationRequested||i.isDisposed()||i.getVersionId()!==s)return;const h=await r.provideInlineEdit(i,{triggerKind:a},o);return h&&!o.isCancellationRequested&&!i.isDisposed()&&i.getVersionId()===s&&this.validateInlineEdit(e,h)?h:void 0}async getInlineEdit(e,t){this._isCursorAtInlineEditContext.set(!1),await this.clear();const i=await this.fetchInlineEdit(e,t);i&&this._currentEdit.set(i,void 0)}async trigger(){await this.getInlineEdit(this.editor,!1)}async jumpBack(){this._jumpBackPosition&&(this.editor.setPosition(this._jumpBackPosition),this.editor.revealPositionInCenterIfOutsideViewport(this._jumpBackPosition))}async accept(){this._isAccepting.set(!0,void 0);const e=this._currentEdit.get();if(!e)return;let t=e.text;e.text.startsWith("\n")&&(t=e.text.substring(1)),this.editor.pushUndoStop(),this.editor.executeEdits("acceptCurrent",[a.k.replace(c.Q.lift(e.range),t)]),e.accepted&&await this._commandService.executeCommand(e.accepted.id,...e.accepted.arguments||[]).then(void 0,Y.M_),this.freeEdit(e),(0,o.Rn)((e=>{this._currentEdit.set(void 0,e),this._isAccepting.set(!1,e)}))}jumpToCurrent(){this._jumpBackPosition=this.editor.getSelection()?.getStartPosition();const e=this._currentEdit.get();if(!e)return;const t=l.y.lift({lineNumber:e.range.startLineNumber,column:e.range.startColumn});this.editor.setPosition(t),this.editor.revealPositionInCenterIfOutsideViewport(t)}async clear(e=!0){const t=this._currentEdit.get();t&&t?.rejected&&e&&await this._commandService.executeCommand(t.rejected.id,...t.rejected.arguments||[]).then(void 0,Y.M_),t&&this.freeEdit(t),this._currentEdit.set(void 0,void 0)}freeEdit(e){const t=this.editor.getModel();if(!t)return;const i=this.languageFeaturesService.inlineEditProvider.all(t);0!==i.length&&i[0].freeInlineEdit(e)}};he=ae=le([ce(1,E._Y),ce(2,b.fN),ce(3,y.ILanguageFeaturesService),ce(4,R.d),ce(5,K.pG),ce(6,Z.Hg),ce(7,te.IModelService)],he);class de extends s.ks{constructor(){super({id:"editor.action.inlineEdit.accept",label:"Accept Inline Edit",alias:"Accept Inline Edit",precondition:b.M$.and(n.R.writable,he.inlineEditVisibleContext),kbOpts:[{weight:101,primary:2,kbExpr:b.M$.and(n.R.writable,he.inlineEditVisibleContext,he.cursorAtInlineEditContext)}],menuOpts:[{menuId:D.D8.InlineEditToolbar,title:"Accept",group:"primary",order:1}]})}async run(e,t){const i=he.get(t);await(i?.accept())}}class ue extends s.ks{constructor(){const e=b.M$.and(n.R.writable,b.M$.not(he.inlineEditVisibleKey));super({id:"editor.action.inlineEdit.trigger",label:"Trigger Inline Edit",alias:"Trigger Inline Edit",precondition:e,kbOpts:{weight:101,primary:2646,kbExpr:e}})}async run(e,t){const i=he.get(t);i?.trigger()}}class ge extends s.ks{constructor(){const e=b.M$.and(n.R.writable,he.inlineEditVisibleContext,b.M$.not(he.cursorAtInlineEditKey));super({id:"editor.action.inlineEdit.jumpTo",label:"Jump to Inline Edit",alias:"Jump to Inline Edit",precondition:e,kbOpts:{weight:101,primary:2646,kbExpr:e},menuOpts:[{menuId:D.D8.InlineEditToolbar,title:"Jump To Edit",group:"primary",order:3,when:e}]})}async run(e,t){const i=he.get(t);i?.jumpToCurrent()}}class pe extends s.ks{constructor(){const e=b.M$.and(n.R.writable,he.cursorAtInlineEditContext);super({id:"editor.action.inlineEdit.jumpBack",label:"Jump Back from Inline Edit",alias:"Jump Back from Inline Edit",precondition:e,kbOpts:{weight:110,primary:2646,kbExpr:e},menuOpts:[{menuId:D.D8.InlineEditToolbar,title:"Jump Back",group:"primary",order:3,when:e}]})}async run(e,t){const i=he.get(t);i?.jumpBack()}}class me extends s.ks{constructor(){const e=b.M$.and(n.R.writable,he.inlineEditVisibleContext);super({id:"editor.action.inlineEdit.reject",label:"Reject Inline Edit",alias:"Reject Inline Edit",precondition:e,kbOpts:{weight:100,primary:9,kbExpr:e},menuOpts:[{menuId:D.D8.InlineEditToolbar,title:"Reject",group:"secondary",order:2}]})}async run(e,t){const i=he.get(t);await(i?.clear())}}(0,s.Fl)(de),(0,s.Fl)(me),(0,s.Fl)(ge),(0,s.Fl)(pe),(0,s.Fl)(ue),(0,s.HW)(he.ID,he,3)},40677:(e,t,i)=>{"use strict";var s=i(31450),n=i(10350),r=i(31308),o=i(49154),a=i(29163),l=i(60002),c=i(78209),h=i(32848);const d=new h.N1("inlineEditsVisible",!1,(0,c.kg)("inlineEditsVisible","Whether an inline edit is visible")),u=new h.N1("inlineEditsIsPinned",!1,(0,c.kg)("isPinned","Whether an inline edit is visible"));var g=i(5662),p=i(87958),m=i(38844),f=i(41127),_=i(75326),v=i(32500),C=i(56942),b=i(90766),E=i(18447),S=i(51241),y=i(64383),w=i(79400),L=i(94746),R=i(86571),T=i(62083),x=i(23750),k=i(20940),A=i(8597),N=i(49435),I=i(10691),O=i(92368),D=i(83941),M=i(87289),P=i(18864),F=i(1098),U=i(90870),H=i(63591),B=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},W=function(e,t){return function(i,s){t(i,s,e)}};class V{constructor(e,t,i){this.range=e,this.newLines=t,this.changes=i}}let z=class extends g.jG{constructor(e,t,i,n){super(),this._editor=e,this._edit=t,this._userPrompt=i,this._instantiationService=n,this._editorObs=(0,m.Ud)(this._editor),this._elements=(0,A.h)("div.inline-edits-widget",{style:{position:"absolute",overflow:"visible",top:"0px",left:"0px"}},[(0,A.h)("div@editorContainer",{style:{position:"absolute",top:"0px",left:"0px",width:"500px",height:"500px"}},[(0,A.h)("div.toolbar@toolbar",{style:{position:"absolute",top:"-25px",left:"0px"}}),(0,A.h)("div.promptEditor@promptEditor",{style:{position:"absolute",top:"-25px",left:"80px",width:"300px",height:"22px"}}),(0,A.h)("div.preview@editor",{style:{position:"absolute",top:"0px",left:"0px"}})]),(0,A.Mc)("svg",{style:{overflow:"visible",pointerEvents:"none"}},[(0,A.Mc)("defs",[(0,A.Mc)("linearGradient",{id:"Gradient2",x1:"0",y1:"0",x2:"1",y2:"0"},[(0,A.Mc)("stop",{offset:"0%",class:"gradient-stop"}),(0,A.Mc)("stop",{offset:"100%",class:"gradient-stop"})])]),(0,A.Mc)("path@path",{d:"",fill:"url(#Gradient2)"})])]),this._previewTextModel=this._register(this._instantiationService.createInstance(M.Bz,"",D.vH,M.Bz.DEFAULT_CREATION_OPTIONS,null)),this._setText=(0,r.un)((e=>{const t=this._edit.read(e);t&&this._previewTextModel.setValue(t.newLines.join("\n"))})).recomputeInitiallyAndOnChange(this._store),this._promptTextModel=this._register(this._instantiationService.createInstance(M.Bz,"",D.vH,M.Bz.DEFAULT_CREATION_OPTIONS,null)),this._promptEditor=this._register(this._instantiationService.createInstance(a.t,this._elements.promptEditor,{glyphMargin:!1,lineNumbers:"off",minimap:{enabled:!1},guides:{indentation:!1,bracketPairs:!1,bracketPairsHorizontal:!1,highlightActiveIndentation:!1},folding:!1,selectOnLineNumbers:!1,selectionHighlight:!1,columnSelection:!1,overviewRulerBorder:!1,overviewRulerLanes:0,lineDecorationsWidth:0,lineNumbersMinChars:0,placeholder:"Describe the change you want...",fontFamily:N.z},{contributions:s.dS.getSomeEditorContributions([U.D.ID,F.X.ID,P.d.ID]),isSimpleWidget:!0},this._editor)),this._previewEditor=this._register(this._instantiationService.createInstance(a.t,this._elements.editor,{glyphMargin:!1,lineNumbers:"off",minimap:{enabled:!1},guides:{indentation:!1,bracketPairs:!1,bracketPairsHorizontal:!1,highlightActiveIndentation:!1},folding:!1,selectOnLineNumbers:!1,selectionHighlight:!1,columnSelection:!1,overviewRulerBorder:!1,overviewRulerLanes:0,lineDecorationsWidth:0,lineNumbersMinChars:0},{contributions:[]},this._editor)),this._previewEditorObs=(0,m.Ud)(this._previewEditor),this._decorations=(0,r.un)(this,(e=>{this._setText.read(e);const t=this._edit.read(e)?.changes;if(!t)return[];const i=[],s=[];if(1===t.length&&t[0].innerChanges[0].modifiedRange.equalsRange(this._previewTextModel.getFullModelRange()))return[];for(const n of t)if(n.original.isEmpty||i.push({range:n.original.toInclusiveRange(),options:I.Ob}),n.modified.isEmpty||s.push({range:n.modified.toInclusiveRange(),options:I.Kl}),n.modified.isEmpty||n.original.isEmpty)n.original.isEmpty||i.push({range:n.original.toInclusiveRange(),options:I.KL}),n.modified.isEmpty||s.push({range:n.modified.toInclusiveRange(),options:I.Ou});else for(const e of n.innerChanges||[])n.original.contains(e.originalRange.startLineNumber)&&i.push({range:e.originalRange,options:e.originalRange.isEmpty()?I.wp:I.Zb}),n.modified.contains(e.modifiedRange.startLineNumber)&&s.push({range:e.modifiedRange,options:e.modifiedRange.isEmpty()?I.GM:I.bk});return s})),this._layout1=(0,r.un)(this,(e=>{const t=this._editor.getModel(),i=this._edit.read(e);if(!i)return null;const s=i.range;let n=0;for(let r=s.startLineNumber;r{const t=this._edit.read(e);if(!t)return null;const i=t.range,s=this._editorObs.scrollLeft.read(e),n=this._layout1.read(e).left+20-s,r=this._editor.getTopForLineNumber(i.startLineNumber)-this._editorObs.scrollTop.read(e),o=this._editor.getTopForLineNumber(i.endLineNumberExclusive)-this._editorObs.scrollTop.read(e),a=new G(n,r),l=new G(n,o),c=o-r,h=this._editor.getOption(67)*t.newLines.length,d=c-h;return{topCode:a,bottomCode:l,codeHeight:c,topEdit:new G(n+50,r+d/2),bottomEdit:new G(n+50,o-d/2),editHeight:h}}));const o=(0,r.un)(this,(e=>void 0!==this._edit.read(e)||void 0!==this._userPrompt.read(e)));var l,c,h;this._register((0,O.AV)(this._elements.root,{display:(0,r.un)(this,(e=>o.read(e)?"block":"none"))})),this._register((0,O.rX)(this._editor.getDomNode(),this._elements.root)),this._register((0,m.Ud)(e).createOverlayWidget({domNode:this._elements.root,position:(0,r.lk)(null),allowEditorOverflow:!1,minContentWidthInPx:(0,r.un)((e=>{const t=this._layout1.read(e)?.left;if(void 0===t)return 0;return t+this._previewEditorObs.contentWidth.read(e)}))})),this._previewEditor.setModel(this._previewTextModel),this._register(this._previewEditorObs.setDecorations(this._decorations)),this._register((0,r.fm)((e=>{const t=this._layout.read(e);if(!t)return;const{topCode:i,bottomCode:s,topEdit:n,bottomEdit:r,editHeight:o}=t,a=(new j).moveTo(i).lineTo(i.deltaX(10)).curveTo(i.deltaX(50),n.deltaX(-40),n.deltaX(-0)).lineTo(n).lineTo(r).lineTo(r.deltaX(-0)).curveTo(r.deltaX(-40),s.deltaX(50),s.deltaX(10)).lineTo(s).build();this._elements.path.setAttribute("d",a),this._elements.editorContainer.style.top=`${n.y}px`,this._elements.editorContainer.style.left=`${n.x}px`,this._elements.editorContainer.style.height=`${o}px`;const l=this._previewEditorObs.contentWidth.read(e);this._previewEditor.layout({height:o,width:l})}))),this._promptEditor.setModel(this._promptTextModel),this._promptEditor.layout(),this._register(function(e,t){const i=new g.Cm;return i.add((0,r.fm)((i=>{const s=e.read(i);t.set(s,void 0)}))),i.add((0,r.fm)((i=>{const s=t.read(i);e.set(s,void 0)}))),i}((l=this._userPrompt,c=e=>e??"",h=e=>e,(0,p.dQ)(void 0,(e=>c(l.read(e))),((e,t)=>l.set(h(e),t)))),(0,m.Ud)(this._promptEditor).value)),this._register((0,r.fm)((e=>{const t=(0,m.Ud)(this._promptEditor).isFocused.read(e);this._elements.root.classList.toggle("focused",t)})))}};z=B([W(3,H._Y)],z);class G{constructor(e,t){this.x=e,this.y=t}deltaX(e){return new G(this.x+e,this.y)}}class j{constructor(){this._data=""}moveTo(e){return this._data+=`M ${e.x} ${e.y} `,this}lineTo(e){return this._data+=`L ${e.x} ${e.y} `,this}curveTo(e,t,i){return this._data+=`C ${e.x} ${e.y} ${t.x} ${t.y} ${i.x} ${i.y} `,this}build(){return this._data}}var K,Y=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},q=function(e,t){return function(i,s){t(i,s,e)}};let $=class extends g.jG{static{K=this}static{this._modelId=0}static _createUniqueUri(){return w.r.from({scheme:"inline-edits",path:(new Date).toString()+String(K._modelId++)})}constructor(e,t,i,s,n,o,a){super(),this.textModel=e,this._textModelVersionId=t,this._selection=i,this._debounceValue=s,this.languageFeaturesService=n,this._diffProviderFactoryService=o,this._modelService=a,this._forceUpdateExplicitlySignal=(0,r.Yd)(this),this._selectedInlineCompletionId=(0,r.FY)(this,void 0),this._isActive=(0,r.FY)(this,!1),this._originalModel=(0,p.a0)((()=>this._modelService.createModel("",null,K._createUniqueUri()))).keepObserved(this._store),this._modifiedModel=(0,p.a0)((()=>this._modelService.createModel("",null,K._createUniqueUri()))).keepObserved(this._store),this._pinnedRange=new X(this.textModel,this._textModelVersionId),this.isPinned=this._pinnedRange.range.map((e=>!!e)),this.userPrompt=(0,r.FY)(this,void 0),this.inlineEdit=(0,r.un)(this,(e=>this._inlineEdit.read(e)?.promiseResult.read(e)?.data)),this._inlineEdit=(0,r.un)(this,(e=>{const t=this.selectedInlineEdit.read(e);if(!t)return;const i=t.inlineCompletion.range;if(""===t.inlineCompletion.insertText.trim())return;let s=t.inlineCompletion.insertText.split(/\r\n|\r|\n/);function n(e){const t=e[0].match(/^\s*/)?.[0]??"";return e.map((e=>e.replace(new RegExp("^"+t),"")))}s=n(s);let o=this.textModel.getValueInRange(i).split(/\r\n|\r|\n/);o=n(o),this._originalModel.get().setValue(o.join("\n")),this._modifiedModel.get().setValue(s.join("\n"));const a=this._diffProviderFactoryService.createDiffProvider({diffAlgorithm:"advanced"});return r.BK.fromFn((async()=>{const e=await a.computeDiff(this._originalModel.get(),this._modifiedModel.get(),{computeMoves:!1,ignoreTrimWhitespace:!1,maxComputationTimeMs:1e3},E.XO.None);if(!e.identical)return new V(R.M.fromRangeInclusive(i),n(s),e.changes)}))})),this._fetchStore=this._register(new g.Cm),this._inlineEditsFetchResult=(0,r.X2)(this,void 0),this._inlineEdits=(0,r.C)({owner:this,equalsFn:S.dB},(e=>this._inlineEditsFetchResult.read(e)?.completions.map((e=>new Q(e)))??[])),this._fetchInlineEditsPromise=(0,r.nb)({owner:this,createEmptyChangeSummary:()=>({inlineCompletionTriggerKind:T.qw.Automatic}),handleChange:(e,t)=>(e.didChange(this._forceUpdateExplicitlySignal)&&(t.inlineCompletionTriggerKind=T.qw.Explicit),!0)},(async(e,t)=>{this._fetchStore.clear(),this._forceUpdateExplicitlySignal.read(e),this._textModelVersionId.read(e);const i=this._pinnedRange.range.read(e)??(s=this._selection.read(e),(e=>e.isEmpty()?void 0:e)(s));var s;if(!i)return this._inlineEditsFetchResult.set(void 0,void 0),void this.userPrompt.set(void 0,void 0);const n={triggerKind:t.inlineCompletionTriggerKind,selectedSuggestionInfo:void 0,userPrompt:this.userPrompt.read(e)},r=(0,E.bs)(this._fetchStore);await(0,b.wR)(200,r);const o=await(0,k.Yk)(this.languageFeaturesService.inlineCompletionsProvider,i,this.textModel,n,r);r.isCancellationRequested||this._inlineEditsFetchResult.set(o,void 0)})),this._filteredInlineEditItems=(0,r.C)({owner:this,equalsFn:(0,S.S3)()},(e=>this._inlineEdits.read(e))),this.selectedInlineCompletionIndex=(0,r.un)(this,(e=>{const t=this._selectedInlineCompletionId.read(e),i=this._filteredInlineEditItems.read(e),s=void 0===this._selectedInlineCompletionId?-1:i.findIndex((e=>e.semanticId===t));return-1===s?(this._selectedInlineCompletionId.set(void 0,void 0),0):s})),this.selectedInlineEdit=(0,r.un)(this,(e=>this._filteredInlineEditItems.read(e)[this.selectedInlineCompletionIndex.read(e)])),this._register((0,r.OI)(this._fetchInlineEditsPromise))}async triggerExplicitly(e){(0,r.PO)(e,(e=>{this._isActive.set(!0,e),this._forceUpdateExplicitlySignal.trigger(e)})),await this._fetchInlineEditsPromise.get()}stop(e){(0,r.PO)(e,(e=>{this.userPrompt.set(void 0,e),this._isActive.set(!1,e),this._inlineEditsFetchResult.set(void 0,e),this._pinnedRange.setRange(void 0,e)}))}async _deltaSelectedInlineCompletionIndex(e){await this.triggerExplicitly();const t=this._filteredInlineEditItems.get()||[];if(t.length>0){const i=(this.selectedInlineCompletionIndex.get()+e+t.length)%t.length;this._selectedInlineCompletionId.set(t[i].semanticId,void 0)}else this._selectedInlineCompletionId.set(void 0,void 0)}async next(){await this._deltaSelectedInlineCompletionIndex(1)}async previous(){await this._deltaSelectedInlineCompletionIndex(-1)}async accept(e){if(e.getModel()!==this.textModel)throw new y.D7;const t=this.selectedInlineEdit.get();t&&(e.pushUndoStop(),e.executeEdits("inlineSuggestion.accept",[t.inlineCompletion.toSingleTextEdit().toSingleEditOperation()]),this.stop())}};$=K=Y([q(4,C.ILanguageFeaturesService),q(5,L.Hg),q(6,x.IModelService)],$);class Q{constructor(e){this.inlineCompletion=e,this.semanticId=this.inlineCompletion.hash()}}class X extends g.jG{constructor(e,t){super(),this._textModel=e,this._versionId=t,this._decorations=(0,r.FY)(this,[]),this.range=(0,r.un)(this,(e=>{this._versionId.read(e);const t=this._decorations.read(e)[0];return t?this._textModel.getDecorationRange(t)??null:null})),this._register((0,g.s)((()=>{this._textModel.deltaDecorations(this._decorations.get(),[])})))}setRange(e,t){this._decorations.set(this._textModel.deltaDecorations(this._decorations.get(),e?[{range:e,options:{description:"trackedRange"}}]:[]),t)}}var Z,J=i(84001),ee=i(71319),te=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ie=function(e,t){return function(i,s){t(i,s,e)}};let se=class extends g.jG{static{Z=this}static{this.ID="editor.contrib.inlineEditsController"}static get(e){return e.getContribution(Z.ID)}constructor(e,t,i,s,n,o){super(),this.editor=e,this._instantiationService=t,this._contextKeyService=i,this._debounceService=s,this._languageFeaturesService=n,this._configurationService=o,this._enabled=(0,ee.V)("editor.inlineEdits.enabled",!1,this._configurationService),this._editorObs=(0,m.Ud)(this.editor),this._selection=(0,r.un)(this,(e=>this._editorObs.cursorSelection.read(e)??new _.L(1,1,1,1))),this._debounceValue=this._debounceService.for(this._languageFeaturesService.inlineCompletionsProvider,"InlineEditsDebounce",{min:50,max:50}),this.model=(0,p.a0)(this,(e=>{if(!this._enabled.read(e))return;if(this._editorObs.isReadonly.read(e))return;const t=this._editorObs.model.read(e);if(!t)return;return this._instantiationService.createInstance((0,f.b)($,e),t,this._editorObs.versionId,this._selection,this._debounceValue)})),this._hadInlineEdit=(0,r.ZX)(this,((e,t)=>t||void 0!==this.model.read(e)?.inlineEdit.read(e))),this._widget=(0,p.a0)(this,(e=>{var t;if(this._hadInlineEdit.read(e))return this._instantiationService.createInstance((0,f.b)(z,e),this.editor,this.model.map(((e,t)=>e?.inlineEdit.read(t))),(t=e=>this.model.read(e)?.userPrompt??(0,r.FY)("empty",""),(0,p.dQ)(void 0,(e=>t(e).read(e)),((e,i)=>{t(void 0).set(e,i)}))))})),this._register((0,ee.w)(d,this._contextKeyService,(e=>!!this.model.read(e)?.inlineEdit.read(e)))),this._register((0,ee.w)(u,this._contextKeyService,(e=>!!this.model.read(e)?.isPinned.read(e)))),this.model.recomputeInitiallyAndOnChange(this._store),this._widget.recomputeInitiallyAndOnChange(this._store)}};se=Z=te([ie(1,H._Y),ie(2,h.fN),ie(3,v.ILanguageFeatureDebounceService),ie(4,C.ILanguageFeaturesService),ie(5,J.pG)],se);var ne=i(27195);function re(e){return{label:e.value,alias:e.original}}class oe extends s.ks{static{this.ID="editor.action.inlineEdits.showNext"}constructor(){super({id:oe.ID,...re(c.aS("action.inlineEdits.showNext","Show Next Inline Edit")),precondition:h.M$.and(l.R.writable,d),kbOpts:{weight:100,primary:606}})}async run(e,t){const i=se.get(t);i?.model.get()?.next()}}class ae extends s.ks{static{this.ID="editor.action.inlineEdits.showPrevious"}constructor(){super({id:ae.ID,...re(c.aS("action.inlineEdits.showPrevious","Show Previous Inline Edit")),precondition:h.M$.and(l.R.writable,d),kbOpts:{weight:100,primary:604}})}async run(e,t){const i=se.get(t);i?.model.get()?.previous()}}class le extends s.ks{constructor(){super({id:"editor.action.inlineEdits.trigger",...re(c.aS("action.inlineEdits.trigger","Trigger Inline Edit")),precondition:l.R.writable})}async run(e,t){const i=se.get(t);await(0,o.fL)((async e=>{await(i?.model.get()?.triggerExplicitly(e))}))}}class ce extends s.ks{constructor(){super({id:"editor.action.inlineEdits.accept",...re(c.aS("action.inlineEdits.accept","Accept Inline Edit")),precondition:d,menuOpts:{menuId:ne.D8.InlineEditsActions,title:c.kg("inlineEditsActions","Accept Inline Edit"),group:"primary",order:1,icon:n.W.check},kbOpts:{primary:2058,weight:2e4,kbExpr:d}})}async run(e,t){t instanceof a.t&&(t=t.getParentEditor());const i=se.get(t);i&&(i.model.get()?.accept(i.editor),i.editor.focus())}}class he extends s.ks{static{this.ID="editor.action.inlineEdits.hide"}constructor(){super({id:he.ID,...re(c.aS("action.inlineEdits.hide","Hide Inline Edit")),precondition:d,kbOpts:{weight:100,primary:9}})}async run(e,t){const i=se.get(t);(0,r.Rn)((e=>{i?.model.get()?.stop(e)}))}}(0,s.HW)(se.ID,se,3),(0,s.Fl)(le),(0,s.Fl)(oe),(0,s.Fl)(ae),(0,s.Fl)(ce),(0,s.Fl)(he)},9948:(e,t,i)=>{"use strict";i.d(t,{I:()=>f});var s=i(8597),n=i(90766),r=i(10350),o=i(5662),a=i(91508),l=i(25689),c=i(36677),h=i(87289),d=i(63591),u=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};const p=h.kI.register({description:"inline-progress-widget",stickiness:1,showIfCollapsed:!0,after:{content:a.S8,inlineClassName:"inline-editor-progress-decoration",inlineClassNameAffectsLetterSpacing:!0}});class m extends o.jG{static{this.baseId="editor.widget.inlineProgressWidget"}constructor(e,t,i,s,n){super(),this.typeId=e,this.editor=t,this.range=i,this.delegate=n,this.allowEditorOverflow=!1,this.suppressMouseDown=!0,this.create(s),this.editor.addContentWidget(this),this.editor.layoutContentWidget(this)}create(e){this.domNode=s.$(".inline-progress-widget"),this.domNode.role="button",this.domNode.title=e;const t=s.$("span.icon");this.domNode.append(t),t.classList.add(...l.L.asClassNameArray(r.W.loading),"codicon-modifier-spin");const i=()=>{const e=this.editor.getOption(67);this.domNode.style.height=`${e}px`,this.domNode.style.width=`${Math.ceil(.8*e)}px`};i(),this._register(this.editor.onDidChangeConfiguration((e=>{(e.hasChanged(52)||e.hasChanged(67))&&i()}))),this._register(s.ko(this.domNode,s.Bx.CLICK,(e=>{this.delegate.cancel()})))}getId(){return m.baseId+"."+this.typeId}getDomNode(){return this.domNode}getPosition(){return{position:{lineNumber:this.range.startLineNumber,column:this.range.startColumn},preference:[0]}}dispose(){super.dispose(),this.editor.removeContentWidget(this)}}let f=class extends o.jG{constructor(e,t,i){super(),this.id=e,this._editor=t,this._instantiationService=i,this._showDelay=500,this._showPromise=this._register(new o.HE),this._currentWidget=this._register(new o.HE),this._operationIdPool=0,this._currentDecorations=t.createDecorationsCollection()}dispose(){super.dispose(),this._currentDecorations.clear()}async showWhile(e,t,i,s,r){const o=this._operationIdPool++;this._currentOperation=o,this.clear(),this._showPromise.value=(0,n.EQ)((()=>{const i=c.Q.fromPositions(e);this._currentDecorations.set([{range:i,options:p}]).length>0&&(this._currentWidget.value=this._instantiationService.createInstance(m,this.id,this._editor,i,t,s))}),r??this._showDelay);try{return await i}finally{this._currentOperation===o&&(this.clear(),this._currentOperation=void 0)}}clear(){this._showPromise.clear(),this._currentDecorations.clear(),this._currentWidget.clear()}};f=u([g(2,d._Y)],f)},15040:(e,t,i)=>{"use strict";var s=i(31450),n=i(50672),r=i(60002),o=i(78209);class a extends s.ks{constructor(){super({id:"expandLineSelection",label:o.kg("expandLineSelection","Expand Line Selection"),alias:"Expand Line Selection",precondition:void 0,kbOpts:{weight:0,kbExpr:r.R.textInputFocus,primary:2090}})}run(e,t,i){if(i=i||{},!t.hasModel())return;const s=t._getViewModel();s.model.pushStackElement(),s.setCursorStates(i.source,3,n.c.expandLineSelection(s,s.getCursorStates())),s.revealAllCursors(i.source,!0)}}(0,s.Fl)(a)},75639:(e,t,i)=>{"use strict";var s=i(24939),n=i(36999),r=i(31450),o=i(15092),a=i(91508),l=i(7085),c=i(36677);class h{constructor(e,t,i){this._selection=e,this._cursors=t,this._selectionId=null,this._trimInRegexesAndStrings=i}getEditOperations(e,t){const i=function(e,t,i){t.sort(((e,t)=>e.lineNumber===t.lineNumber?e.column-t.column:e.lineNumber-t.lineNumber));for(let a=t.length-2;a>=0;a--)t[a].lineNumber===t[a+1].lineNumber&&t.splice(a,1);const s=[];let n=0,r=0;const o=t.length;for(let h=1,d=e.getLineCount();h<=d;h++){const d=e.getLineContent(h),u=d.length+1;let g=0;if(r=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},w=function(e,t){return function(i,s){t(i,s,e)}};let L=class{constructor(e,t,i,s){this._languageConfigurationService=s,this._selection=e,this._isMovingDown=t,this._autoIndent=i,this._selectionId=null,this._moveEndLineSelectionShrink=!1}getEditOperations(e,t){const i=()=>e.getLanguageId(),s=(t,i)=>e.getLanguageIdAtPosition(t,i),n=e.getLineCount();if(this._isMovingDown&&this._selection.endLineNumber===n)return void(this._selectionId=t.trackSelection(this._selection));if(!this._isMovingDown&&1===this._selection.startLineNumber)return void(this._selectionId=t.trackSelection(this._selection));this._moveEndPositionDown=!1;let r=this._selection;r.startLineNumbert===r.startLineNumber?e.tokenization.getLineTokens(n):e.tokenization.getLineTokens(t),getLanguageId:i,getLanguageIdAtPosition:s},getLineContent:t=>t===r.startLineNumber?e.getLineContent(n):e.getLineContent(t)},c=(0,E.$f)(this._autoIndent,t,e.getLanguageIdAtPosition(n,1),r.startLineNumber,d,this._languageConfigurationService);if(null!==c){const t=a.UU(e.getLineContent(n)),i=b.c(c,o);if(i!==b.c(t,o)){const e=b.k(i,o,h);u=e+this.trimStart(l)}}}t.addEditOperation(new c.Q(r.startLineNumber,1,r.startLineNumber,1),u+"\n");const p=this.matchEnterRuleMovingDown(e,d,o,r.startLineNumber,n,u);if(null!==p)0!==p&&this.getIndentEditsOfMovingBlock(e,t,r,o,h,p);else{const l={tokenization:{getLineTokens:t=>t===r.startLineNumber?e.tokenization.getLineTokens(n):t>=r.startLineNumber+1&&t<=r.endLineNumber+1?e.tokenization.getLineTokens(t-1):e.tokenization.getLineTokens(t),getLanguageId:i,getLanguageIdAtPosition:s},getLineContent:t=>t===r.startLineNumber?u:t>=r.startLineNumber+1&&t<=r.endLineNumber+1?e.getLineContent(t-1):e.getLineContent(t)},c=(0,E.$f)(this._autoIndent,l,e.getLanguageIdAtPosition(n,1),r.startLineNumber+1,d,this._languageConfigurationService);if(null!==c){const i=a.UU(e.getLineContent(r.startLineNumber)),s=b.c(c,o),n=b.c(i,o);if(s!==n){const i=s-n;this.getIndentEditsOfMovingBlock(e,t,r,o,h,i)}}}}else t.addEditOperation(new c.Q(r.startLineNumber,1,r.startLineNumber,1),u+"\n")}else if(n=r.startLineNumber-1,l=e.getLineContent(n),t.addEditOperation(new c.Q(n,1,n+1,1),null),t.addEditOperation(new c.Q(r.endLineNumber,e.getLineMaxColumn(r.endLineNumber),r.endLineNumber,e.getLineMaxColumn(r.endLineNumber)),"\n"+l),this.shouldAutoIndent(e,r)){const l={tokenization:{getLineTokens:t=>t===n?e.tokenization.getLineTokens(r.startLineNumber):e.tokenization.getLineTokens(t),getLanguageId:i,getLanguageIdAtPosition:s},getLineContent:t=>t===n?e.getLineContent(r.startLineNumber):e.getLineContent(t)},c=this.matchEnterRule(e,d,o,r.startLineNumber,r.startLineNumber-2);if(null!==c)0!==c&&this.getIndentEditsOfMovingBlock(e,t,r,o,h,c);else{const i=(0,E.$f)(this._autoIndent,l,e.getLanguageIdAtPosition(r.startLineNumber,1),n,d,this._languageConfigurationService);if(null!==i){const s=a.UU(e.getLineContent(r.startLineNumber)),n=b.c(i,o),l=b.c(s,o);if(n!==l){const i=n-l;this.getIndentEditsOfMovingBlock(e,t,r,o,h,i)}}}}}this._selectionId=t.trackSelection(r)}buildIndentConverter(e,t,i){return{shiftIndent:s=>_.Y.shiftIndent(s,s.length+1,e,t,i),unshiftIndent:s=>_.Y.unshiftIndent(s,s.length+1,e,t,i)}}parseEnterResult(e,t,i,s,n){if(n){let r=n.indentation;n.indentAction===v.l.None||n.indentAction===v.l.Indent?r=n.indentation+n.appendText:n.indentAction===v.l.IndentOutdent?r=n.indentation:n.indentAction===v.l.Outdent&&(r=t.unshiftIndent(n.indentation)+n.appendText);const o=e.getLineContent(s);if(this.trimStart(o).indexOf(this.trimStart(r))>=0){const n=a.UU(e.getLineContent(s));let o=a.UU(r);const l=(0,E.Yb)(e,s,this._languageConfigurationService);null!==l&&2&l&&(o=t.unshiftIndent(o));return b.c(o,i)-b.c(n,i)}}return null}matchEnterRuleMovingDown(e,t,i,s,n,r){if(a.lT(r)>=0){const r=e.getLineMaxColumn(n),o=(0,S.h)(this._autoIndent,e,new c.Q(n,r,n,r),this._languageConfigurationService);return this.parseEnterResult(e,t,i,s,o)}{let n=s-1;for(;n>=1;){const t=e.getLineContent(n);if(a.lT(t)>=0)break;n--}if(n<1||s>e.getLineCount())return null;const r=e.getLineMaxColumn(n),o=(0,S.h)(this._autoIndent,e,new c.Q(n,r,n,r),this._languageConfigurationService);return this.parseEnterResult(e,t,i,s,o)}}matchEnterRule(e,t,i,s,n,r){let o=n;for(;o>=1;){let t;t=o===n&&void 0!==r?r:e.getLineContent(o);if(a.lT(t)>=0)break;o--}if(o<1||s>e.getLineCount())return null;const l=e.getLineMaxColumn(o),h=(0,S.h)(this._autoIndent,e,new c.Q(o,l,o,l),this._languageConfigurationService);return this.parseEnterResult(e,t,i,s,h)}trimStart(e){return e.replace(/^\s+/,"")}shouldAutoIndent(e,t){if(this._autoIndent<4)return!1;if(!e.tokenization.isCheapToTokenize(t.startLineNumber))return!1;const i=e.getLanguageIdAtPosition(t.startLineNumber,1);return i===e.getLanguageIdAtPosition(t.endLineNumber,1)&&null!==this._languageConfigurationService.getLanguageConfiguration(i).indentRulesSupport}getIndentEditsOfMovingBlock(e,t,i,s,n,r){for(let o=i.startLineNumber;o<=i.endLineNumber;o++){const l=e.getLineContent(o),h=a.UU(l),d=b.c(h,s)+r,u=b.k(d,s,n);u!==h&&(t.addEditOperation(new c.Q(o,1,o,h.length+1),u),o===i.endLineNumber&&i.endColumn<=h.length+1&&""===u&&(this._moveEndLineSelectionShrink=!0))}}computeCursorState(e,t){let i=t.getTrackedSelection(this._selectionId);return this._moveEndPositionDown&&(i=i.setEndPosition(i.endLineNumber+1,1)),this._moveEndLineSelectionShrink&&i.startLineNumber=n)return null;const r=[];for(let a=s;a<=n;a++)r.push(e.getLineContent(a));let o=r.slice(0);return o.sort(R.getCollator().compare),!0===i&&(o=o.reverse()),{startLineNumber:s,endLineNumber:n,before:r,after:o}}var x=i(78209),k=i(27195),A=i(84001);class N extends r.ks{constructor(e,t){super(t),this.down=e}run(e,t){if(!t.hasModel())return;const i=t.getSelections().map(((e,t)=>({selection:e,index:t,ignore:!1})));i.sort(((e,t)=>c.Q.compareRangesUsingStarts(e.selection,t.selection)));let s=i[0];for(let r=1;rnew g.y(e.positionLineNumber,e.positionColumn))));const n=t.getSelection();if(null===n)return;const r=e.get(A.pG),o=t.getModel(),a=r.getValue("files.trimTrailingWhitespaceInRegexAndStrings",{overrideIdentifier:o?.getLanguageId(),resource:o?.uri}),l=new h(n,s,a);t.pushUndoStop(),t.executeCommands(this.id,[l]),t.pushUndoStop()}}class F extends r.ks{constructor(){super({id:"editor.action.deleteLines",label:x.kg("lines.delete","Delete Line"),alias:"Delete Line",precondition:m.R.writable,kbOpts:{kbExpr:m.R.textInputFocus,primary:3113,weight:100}})}run(e,t){if(!t.hasModel())return;const i=this._getLinesToRemove(t),s=t.getModel();if(1===s.getLineCount()&&1===s.getLineMaxColumn(1))return;let n=0;const r=[],o=[];for(let a=0,c=i.length;a1&&(t-=1,h=s.getLineMaxColumn(t)),r.push(l.k.replace(new p.L(t,h,c,d),"")),o.push(new p.L(t-n,e.positionColumn,t-n,e.positionColumn)),n+=e.endLineNumber-e.startLineNumber+1}t.pushUndoStop(),t.executeEdits(this.id,r,o),t.pushUndoStop()}_getLinesToRemove(e){const t=e.getSelections().map((e=>{let t=e.endLineNumber;return e.startLineNumbere.startLineNumber===t.startLineNumber?e.endLineNumber-t.endLineNumber:e.startLineNumber-t.startLineNumber));const i=[];let s=t[0];for(let n=1;n=t[n].startLineNumber?s.endLineNumber=t[n].endLineNumber:(i.push(s),s=t[n]);return i.push(s),i}}class U extends r.ks{constructor(){super({id:"editor.action.indentLines",label:x.kg("lines.indent","Indent Line"),alias:"Indent Line",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:2142,weight:100}})}run(e,t){const i=t._getViewModel();i&&(t.pushUndoStop(),t.executeCommands(this.id,d.T.indent(i.cursorConfig,t.getModel(),t.getSelections())),t.pushUndoStop())}}class H extends r.ks{constructor(){super({id:"editor.action.outdentLines",label:x.kg("lines.outdent","Outdent Line"),alias:"Outdent Line",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:2140,weight:100}})}run(e,t){n.Yh.Outdent.runEditorCommand(e,t,null)}}class B extends r.ks{constructor(){super({id:"editor.action.insertLineBefore",label:x.kg("lines.insertBefore","Insert Line Above"),alias:"Insert Line Above",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:3075,weight:100}})}run(e,t){const i=t._getViewModel();i&&(t.pushUndoStop(),t.executeCommands(this.id,u.AO.lineInsertBefore(i.cursorConfig,t.getModel(),t.getSelections())))}}class W extends r.ks{constructor(){super({id:"editor.action.insertLineAfter",label:x.kg("lines.insertAfter","Insert Line Below"),alias:"Insert Line Below",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:2051,weight:100}})}run(e,t){const i=t._getViewModel();i&&(t.pushUndoStop(),t.executeCommands(this.id,u.AO.lineInsertAfter(i.cursorConfig,t.getModel(),t.getSelections())))}}class V extends r.ks{run(e,t){if(!t.hasModel())return;const i=t.getSelection(),s=this._getRangesToDelete(t),n=[];for(let a=0,l=s.length-1;al.k.replace(e,"")));t.pushUndoStop(),t.executeEdits(this.id,o,r),t.pushUndoStop()}}class z extends r.ks{constructor(){super({id:"editor.action.joinLines",label:x.kg("lines.joinLines","Join Lines"),alias:"Join Lines",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:0,mac:{primary:296},weight:100}})}run(e,t){const i=t.getSelections();if(null===i)return;let s=t.getSelection();if(null===s)return;i.sort(c.Q.compareRangesUsingStarts);const n=[],r=i.reduce(((e,t)=>e.isEmpty()?e.endLineNumber===t.startLineNumber?(s.equalsSelection(e)&&(s=t),t):t.startLineNumber>e.endLineNumber+1?(n.push(e),t):new p.L(e.startLineNumber,e.startColumn,t.endLineNumber,t.endColumn):t.startLineNumber>e.endLineNumber?(n.push(e),t):new p.L(e.startLineNumber,e.startColumn,t.endLineNumber,t.endColumn)));n.push(r);const o=t.getModel();if(null===o)return;const a=[],h=[];let d=s,u=0;for(let g=0,m=n.length;g=1){let i=!0;""===v&&(i=!1),!i||" "!==v.charAt(v.length-1)&&"\t"!==v.charAt(v.length-1)||(i=!1,v=v.replace(/[\s\uFEFF\xA0]+$/g," "));const s=e.substr(t-1);v+=(i?" ":"")+s,f=i?s.length+1:s.length}else f=0}const C=new c.Q(t,i,r,m);if(!C.isEmpty()){let i;e.isEmpty()?(a.push(l.k.replace(C,v)),i=new p.L(C.startLineNumber-u,v.length-f+1,t-u,v.length-f+1)):e.startLineNumber===e.endLineNumber?(a.push(l.k.replace(C,v)),i=new p.L(e.startLineNumber-u,e.startColumn,e.endLineNumber-u,e.endColumn)):(a.push(l.k.replace(C,v)),i=new p.L(e.startLineNumber-u,e.startColumn,e.startLineNumber-u,v.length-_)),null!==c.Q.intersectRanges(C,s)?d=i:h.push(i)}u+=C.endLineNumber-C.startLineNumber}h.unshift(d),t.pushUndoStop(),t.executeEdits(this.id,a,h),t.pushUndoStop()}}class G extends r.ks{constructor(){super({id:"editor.action.transpose",label:x.kg("editor.transpose","Transpose Characters around the Cursor"),alias:"Transpose Characters around the Cursor",precondition:m.R.writable})}run(e,t){const i=t.getSelections();if(null===i)return;const s=t.getModel();if(null===s)return;const n=[];for(let r=0,a=i.length;r=a){if(t.lineNumber===s.getLineCount())continue;const e=new c.Q(t.lineNumber,Math.max(1,t.column-1),t.lineNumber+1,1),i=s.getValueInRange(e).split("").reverse().join("");n.push(new o.iu(new p.L(t.lineNumber,Math.max(1,t.column-1),t.lineNumber+1,1),i))}else{const e=new c.Q(t.lineNumber,Math.max(1,t.column-1),t.lineNumber,t.column+1),i=s.getValueInRange(e).split("").reverse().join("");n.push(new o.ui(e,i,new p.L(t.lineNumber,t.column+1,t.lineNumber,t.column+1)))}}t.pushUndoStop(),t.executeCommands(this.id,n),t.pushUndoStop()}}class j extends r.ks{run(e,t){const i=t.getSelections();if(null===i)return;const s=t.getModel();if(null===s)return;const n=t.getOption(132),r=[];for(const o of i)if(o.isEmpty()){const e=o.getStartPosition(),i=t.getConfiguredWordAtPosition(e);if(!i)continue;const a=new c.Q(e.lineNumber,i.startColumn,e.lineNumber,i.endColumn),h=s.getValueInRange(a);r.push(l.k.replace(a,this._modifyText(h,n)))}else{const e=s.getValueInRange(o);r.push(l.k.replace(o,this._modifyText(e,n)))}t.pushUndoStop(),t.executeEdits(this.id,r),t.pushUndoStop()}}class K{constructor(e,t){this._pattern=e,this._flags=t,this._actual=null,this._evaluated=!1}get(){if(!this._evaluated){this._evaluated=!0;try{this._actual=new RegExp(this._pattern,this._flags)}catch(e){}}return this._actual}isSupported(){return null!==this.get()}}class Y extends j{static{this.titleBoundary=new K("(^|[^\\p{L}\\p{N}']|((^|\\P{L})'))\\p{L}","gmu")}constructor(){super({id:"editor.action.transformToTitlecase",label:x.kg("editor.transformToTitlecase","Transform to Title Case"),alias:"Transform to Title Case",precondition:m.R.writable})}_modifyText(e,t){const i=Y.titleBoundary.get();return i?e.toLocaleLowerCase().replace(i,(e=>e.toLocaleUpperCase())):e}}class q extends j{static{this.caseBoundary=new K("(\\p{Ll})(\\p{Lu})","gmu")}static{this.singleLetters=new K("(\\p{Lu}|\\p{N})(\\p{Lu})(\\p{Ll})","gmu")}constructor(){super({id:"editor.action.transformToSnakecase",label:x.kg("editor.transformToSnakecase","Transform to Snake Case"),alias:"Transform to Snake Case",precondition:m.R.writable})}_modifyText(e,t){const i=q.caseBoundary.get(),s=q.singleLetters.get();return i&&s?e.replace(i,"$1_$2").replace(s,"$1_$2$3").toLocaleLowerCase():e}}class $ extends j{static{this.wordBoundary=new K("[_\\s-]","gm")}constructor(){super({id:"editor.action.transformToCamelcase",label:x.kg("editor.transformToCamelcase","Transform to Camel Case"),alias:"Transform to Camel Case",precondition:m.R.writable})}_modifyText(e,t){const i=$.wordBoundary.get();if(!i)return e;const s=e.split(i);return s.shift()+s.map((e=>e.substring(0,1).toLocaleUpperCase()+e.substring(1))).join("")}}class Q extends j{static{this.wordBoundary=new K("[_\\s-]","gm")}static{this.wordBoundaryToMaintain=new K("(?<=\\.)","gm")}constructor(){super({id:"editor.action.transformToPascalcase",label:x.kg("editor.transformToPascalcase","Transform to Pascal Case"),alias:"Transform to Pascal Case",precondition:m.R.writable})}_modifyText(e,t){const i=Q.wordBoundary.get(),s=Q.wordBoundaryToMaintain.get();if(!i||!s)return e;return e.split(s).map((e=>e.split(i))).flat().map((e=>e.substring(0,1).toLocaleUpperCase()+e.substring(1))).join("")}}class X extends j{static isSupported(){return[this.caseBoundary,this.singleLetters,this.underscoreBoundary].every((e=>e.isSupported()))}static{this.caseBoundary=new K("(\\p{Ll})(\\p{Lu})","gmu")}static{this.singleLetters=new K("(\\p{Lu}|\\p{N})(\\p{Lu}\\p{Ll})","gmu")}static{this.underscoreBoundary=new K("(\\S)(_)(\\S)","gm")}constructor(){super({id:"editor.action.transformToKebabcase",label:x.kg("editor.transformToKebabcase","Transform to Kebab Case"),alias:"Transform to Kebab Case",precondition:m.R.writable})}_modifyText(e,t){const i=X.caseBoundary.get(),s=X.singleLetters.get(),n=X.underscoreBoundary.get();return i&&s&&n?e.replace(n,"$1-$3").replace(i,"$1-$2").replace(s,"$1-$2").toLocaleLowerCase():e}}(0,r.Fl)(class extends N{constructor(){super(!1,{id:"editor.action.copyLinesUpAction",label:x.kg("lines.copyUp","Copy Line Up"),alias:"Copy Line Up",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:1552,linux:{primary:3600},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miCopyLinesUp",comment:["&& denotes a mnemonic"]},"&&Copy Line Up"),order:1}})}}),(0,r.Fl)(class extends N{constructor(){super(!0,{id:"editor.action.copyLinesDownAction",label:x.kg("lines.copyDown","Copy Line Down"),alias:"Copy Line Down",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:1554,linux:{primary:3602},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miCopyLinesDown",comment:["&& denotes a mnemonic"]},"Co&&py Line Down"),order:2}})}}),(0,r.Fl)(I),(0,r.Fl)(class extends O{constructor(){super(!1,{id:"editor.action.moveLinesUpAction",label:x.kg("lines.moveUp","Move Line Up"),alias:"Move Line Up",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:528,linux:{primary:528},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miMoveLinesUp",comment:["&& denotes a mnemonic"]},"Mo&&ve Line Up"),order:3}})}}),(0,r.Fl)(class extends O{constructor(){super(!0,{id:"editor.action.moveLinesDownAction",label:x.kg("lines.moveDown","Move Line Down"),alias:"Move Line Down",precondition:m.R.writable,kbOpts:{kbExpr:m.R.editorTextFocus,primary:530,linux:{primary:530},weight:100},menuOpts:{menuId:k.D8.MenubarSelectionMenu,group:"2_line",title:x.kg({key:"miMoveLinesDown",comment:["&& denotes a mnemonic"]},"Move &&Line Down"),order:4}})}}),(0,r.Fl)(class extends D{constructor(){super(!1,{id:"editor.action.sortLinesAscending",label:x.kg("lines.sortAscending","Sort Lines Ascending"),alias:"Sort Lines Ascending",precondition:m.R.writable})}}),(0,r.Fl)(class extends D{constructor(){super(!0,{id:"editor.action.sortLinesDescending",label:x.kg("lines.sortDescending","Sort Lines Descending"),alias:"Sort Lines Descending",precondition:m.R.writable})}}),(0,r.Fl)(M),(0,r.Fl)(P),(0,r.Fl)(F),(0,r.Fl)(U),(0,r.Fl)(H),(0,r.Fl)(B),(0,r.Fl)(W),(0,r.Fl)(class extends V{constructor(){super({id:"deleteAllLeft",label:x.kg("lines.deleteAllLeft","Delete All Left"),alias:"Delete All Left",precondition:m.R.writable,kbOpts:{kbExpr:m.R.textInputFocus,primary:0,mac:{primary:2049},weight:100}})}_getEndCursorState(e,t){let i=null;const s=[];let n=0;return t.forEach((t=>{let r;if(1===t.endColumn&&n>0){const e=t.startLineNumber-n;r=new p.L(e,t.startColumn,e,t.startColumn)}else r=new p.L(t.startLineNumber,t.startColumn,t.startLineNumber,t.startColumn);n+=t.endLineNumber-t.startLineNumber,t.intersectRanges(e)?i=r:s.push(r)})),i&&s.unshift(i),s}_getRangesToDelete(e){const t=e.getSelections();if(null===t)return[];let i=t;const s=e.getModel();return null===s?[]:(i.sort(c.Q.compareRangesUsingStarts),i=i.map((e=>{if(e.isEmpty()){if(1===e.startColumn){const t=Math.max(1,e.startLineNumber-1),i=1===e.startLineNumber?1:s.getLineLength(t)+1;return new c.Q(t,i,e.startLineNumber,1)}return new c.Q(e.startLineNumber,1,e.startLineNumber,e.startColumn)}return new c.Q(e.startLineNumber,1,e.endLineNumber,e.endColumn)})),i)}}),(0,r.Fl)(class extends V{constructor(){super({id:"deleteAllRight",label:x.kg("lines.deleteAllRight","Delete All Right"),alias:"Delete All Right",precondition:m.R.writable,kbOpts:{kbExpr:m.R.textInputFocus,primary:0,mac:{primary:297,secondary:[2068]},weight:100}})}_getEndCursorState(e,t){let i=null;const s=[];for(let n=0,r=t.length,o=0;n{if(e.isEmpty()){const i=t.getLineMaxColumn(e.startLineNumber);return e.startColumn===i?new c.Q(e.startLineNumber,e.startColumn,e.startLineNumber+1,1):new c.Q(e.startLineNumber,e.startColumn,e.startLineNumber,i)}return e}));return s.sort(c.Q.compareRangesUsingStarts),s}}),(0,r.Fl)(z),(0,r.Fl)(G),(0,r.Fl)(class extends j{constructor(){super({id:"editor.action.transformToUppercase",label:x.kg("editor.transformToUppercase","Transform to Uppercase"),alias:"Transform to Uppercase",precondition:m.R.writable})}_modifyText(e,t){return e.toLocaleUpperCase()}}),(0,r.Fl)(class extends j{constructor(){super({id:"editor.action.transformToLowercase",label:x.kg("editor.transformToLowercase","Transform to Lowercase"),alias:"Transform to Lowercase",precondition:m.R.writable})}_modifyText(e,t){return e.toLocaleLowerCase()}}),q.caseBoundary.isSupported()&&q.singleLetters.isSupported()&&(0,r.Fl)(q),$.wordBoundary.isSupported()&&(0,r.Fl)($),Q.wordBoundary.isSupported()&&(0,r.Fl)(Q),Y.titleBoundary.isSupported()&&(0,r.Fl)(Y),X.isSupported()&&(0,r.Fl)(X)},85117:(e,t,i)=>{"use strict";var s,n=i(25890),r=i(90766),o=i(18447),a=i(47661),l=i(64383),c=i(41234),h=i(5662),d=i(91508),u=i(79400),g=i(31450),p=i(80301),m=i(83069),f=i(36677),_=i(60002),v=i(87289),C=i(17469),b=i(78209),E=i(32848),S=i(56942),y=i(66261),w=i(32500),L=i(78381),R=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},T=function(e,t){return function(i,s){t(i,s,e)}};const x=new E.N1("LinkedEditingInputVisible",!1);let k=class extends h.jG{static{s=this}static{this.ID="editor.contrib.linkedEditing"}static{this.DECORATION=v.kI.register({description:"linked-editing",stickiness:0,className:"linked-editing-decoration"})}static get(e){return e.getContribution(s.ID)}constructor(e,t,i,s,n){super(),this.languageConfigurationService=s,this._syncRangesToken=0,this._localToDispose=this._register(new h.Cm),this._editor=e,this._providers=i.linkedEditingRangeProvider,this._enabled=!1,this._visibleContextKey=x.bindTo(t),this._debounceInformation=n.for(this._providers,"Linked Editing",{max:200}),this._currentDecorations=this._editor.createDecorationsCollection(),this._languageWordPattern=null,this._currentWordPattern=null,this._ignoreChangeEvent=!1,this._localToDispose=this._register(new h.Cm),this._rangeUpdateTriggerPromise=null,this._rangeSyncTriggerPromise=null,this._currentRequestCts=null,this._currentRequestPosition=null,this._currentRequestModelVersion=null,this._register(this._editor.onDidChangeModel((()=>this.reinitialize(!0)))),this._register(this._editor.onDidChangeConfiguration((e=>{(e.hasChanged(70)||e.hasChanged(94))&&this.reinitialize(!1)}))),this._register(this._providers.onDidChange((()=>this.reinitialize(!1)))),this._register(this._editor.onDidChangeModelLanguage((()=>this.reinitialize(!0)))),this.reinitialize(!0)}reinitialize(e){const t=this._editor.getModel(),i=null!==t&&(this._editor.getOption(70)||this._editor.getOption(94))&&this._providers.has(t);if(i===this._enabled&&!e)return;if(this._enabled=i,this.clearRanges(),this._localToDispose.clear(),!i||null===t)return;this._localToDispose.add(c.Jh.runAndSubscribe(t.onDidChangeLanguageConfiguration,(()=>{this._languageWordPattern=this.languageConfigurationService.getLanguageConfiguration(t.getLanguageId()).getWordDefinition()})));const s=new r.ve(this._debounceInformation.get(t)),n=()=>{this._rangeUpdateTriggerPromise=s.trigger((()=>this.updateRanges()),this._debounceDuration??this._debounceInformation.get(t))},o=new r.ve(0),a=e=>{this._rangeSyncTriggerPromise=o.trigger((()=>this._syncRanges(e)))};this._localToDispose.add(this._editor.onDidChangeCursorPosition((()=>{n()}))),this._localToDispose.add(this._editor.onDidChangeModelContent((e=>{if(!this._ignoreChangeEvent&&this._currentDecorations.length>0){const t=this._currentDecorations.getRange(0);if(t&&e.changes.every((e=>t.intersectRanges(e.range))))return void a(this._syncRangesToken)}n()}))),this._localToDispose.add({dispose:()=>{s.dispose(),o.dispose()}}),this.updateRanges()}_syncRanges(e){if(!this._editor.hasModel()||e!==this._syncRangesToken||0===this._currentDecorations.length)return;const t=this._editor.getModel(),i=this._currentDecorations.getRange(0);if(!i||i.startLineNumber!==i.endLineNumber)return this.clearRanges();const s=t.getValueInRange(i);if(this._currentWordPattern){const e=s.match(this._currentWordPattern);if((e?e[0].length:0)!==s.length)return this.clearRanges()}const n=[];for(let r=1,o=this._currentDecorations.length;r1)return void this.clearRanges();const i=this._editor.getModel(),n=i.getVersionId();if(this._currentRequestPosition&&this._currentRequestModelVersion===n){if(t.equals(this._currentRequestPosition))return;if(this._currentDecorations.length>0){const e=this._currentDecorations.getRange(0);if(e&&e.containsPosition(t))return}}this.clearRanges(),this._currentRequestPosition=t,this._currentRequestModelVersion=n;const r=this._currentRequestCts=new o.Qi;try{const e=new L.W(!1),o=await I(this._providers,i,t,r.token);if(this._debounceInformation.update(i,e.elapsed()),r!==this._currentRequestCts)return;if(this._currentRequestCts=null,n!==i.getVersionId())return;let a=[];o?.ranges&&(a=o.ranges),this._currentWordPattern=o?.wordPattern||this._languageWordPattern;let l=!1;for(let i=0,s=a.length;i({range:e,options:s.DECORATION})));this._visibleContextKey.set(!0),this._currentDecorations.set(c),this._syncRangesToken++}catch(a){(0,l.MB)(a)||(0,l.dz)(a),this._currentRequestCts!==r&&this._currentRequestCts||this.clearRanges()}}};k=s=R([T(1,E.fN),T(2,S.ILanguageFeaturesService),T(3,C.JZ),T(4,w.ILanguageFeatureDebounceService)],k);class A extends g.ks{constructor(){super({id:"editor.action.linkedEditing",label:b.kg("linkedEditing.label","Start Linked Editing"),alias:"Start Linked Editing",precondition:E.M$.and(_.R.writable,_.R.hasRenameProvider),kbOpts:{kbExpr:_.R.editorTextFocus,primary:3132,weight:100}})}runCommand(e,t){const i=e.get(p.T),[s,n]=Array.isArray(t)&&t||[void 0,void 0];return u.r.isUri(s)&&m.y.isIPosition(n)?i.openCodeEditor({resource:s},i.getActiveCodeEditor()).then((e=>{e&&(e.setPosition(n),e.invokeWithinContext((t=>(this.reportTelemetry(t,e),this.run(t,e)))))}),l.dz):super.runCommand(e,t)}run(e,t){const i=k.get(t);return i?Promise.resolve(i.updateRanges(!0)):Promise.resolve()}}const N=g.DX.bindToContribution(k.get);function I(e,t,i,s){const o=e.ordered(t);return(0,r.$1)(o.map((e=>async()=>{try{return await e.provideLinkedEditingRanges(t,i,s)}catch(n){return void(0,l.M_)(n)}})),(e=>!!e&&n.EI(e?.ranges)))}(0,g.E_)(new N({id:"cancelLinkedEditingInput",precondition:x,handler:e=>e.clearRanges(),kbOpts:{kbExpr:_.R.editorTextFocus,weight:199,primary:9,secondary:[1033]}}));(0,y.x1A)("editor.linkedEditingBackground",{dark:a.Q1.fromHex("#f00").transparent(.3),light:a.Q1.fromHex("#f00").transparent(.3),hcDark:a.Q1.fromHex("#f00").transparent(.3),hcLight:a.Q1.white},b.kg("editorLinkedEditingBackground","Background color when the editor auto renames on type."));(0,g.ke)("_executeLinkedEditingProvider",((e,t,i)=>{const{linkedEditingRangeProvider:s}=e.get(S.ILanguageFeaturesService);return I(s,t,i,o.XO.None)})),(0,g.HW)(k.ID,k,1),(0,g.Fl)(A)},14614:(e,t,i)=>{"use strict";var s=i(90766),n=i(18447),r=i(64383),o=i(16980),a=i(5662),l=i(36456),c=i(98067),h=i(89403),d=i(78381),u=i(79400),g=i(31450),p=i(87289),m=i(32500),f=i(56942),_=i(37927),v=i(25890),C=i(631),b=i(36677),E=i(23750),S=i(50091);class y{constructor(e,t){this._link=e,this._provider=t}toJSON(){return{range:this.range,url:this.url,tooltip:this.tooltip}}get range(){return this._link.range}get url(){return this._link.url}get tooltip(){return this._link.tooltip}async resolve(e){return this._link.url?this._link.url:"function"===typeof this._provider.resolveLink?Promise.resolve(this._provider.resolveLink(this._link,e)).then((t=>(this._link=t||this._link,this._link.url?this.resolve(e):Promise.reject(new Error("missing"))))):Promise.reject(new Error("missing"))}}class w{constructor(e){this._disposables=new a.Cm;let t=[];for(const[i,s]of e){const e=i.links.map((e=>new y(e,s)));t=w._union(t,e),(0,a.Xm)(i)&&this._disposables.add(i)}this.links=t}dispose(){this._disposables.dispose(),this.links.length=0}static _union(e,t){const i=[];let s,n,r,o;for(s=0,r=0,n=e.length,o=t.length;sPromise.resolve(e.provideLinks(t,i)).then((t=>{t&&(s[n]=[t,e])}),r.M_)));return Promise.all(n).then((()=>{const e=new w((0,v.Yc)(s));return i.isCancellationRequested?(e.dispose(),new w([])):e}))}S.w.registerCommand("_executeLinkProvider",(async(e,...t)=>{let[i,s]=t;(0,C.j)(i instanceof u.r),"number"!==typeof s&&(s=0);const{linkProvider:r}=e.get(f.ILanguageFeaturesService),o=e.get(E.IModelService).getModel(i);if(!o)return[];const a=await L(r,o,n.XO.None);if(!a)return[];for(let c=0;c=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},N=function(e,t){return function(i,s){t(i,s,e)}};let I=class extends a.jG{static{R=this}static{this.ID="editor.linkDetector"}static get(e){return e.getContribution(R.ID)}constructor(e,t,i,n,r){super(),this.editor=e,this.openerService=t,this.notificationService=i,this.languageFeaturesService=n,this.providers=this.languageFeaturesService.linkProvider,this.debounceInformation=r.for(this.providers,"Links",{min:1e3,max:4e3}),this.computeLinks=this._register(new s.uC((()=>this.computeLinksNow()),1e3)),this.computePromise=null,this.activeLinksList=null,this.currentOccurrences={},this.activeLinkDecorationId=null;const o=this._register(new _.gi(e));this._register(o.onMouseMoveOrRelevantKeyDown((([e,t])=>{this._onEditorMouseMove(e,t)}))),this._register(o.onExecute((e=>{this.onEditorMouseUp(e)}))),this._register(o.onCancel((e=>{this.cleanUpActiveLinkDecoration()}))),this._register(e.onDidChangeConfiguration((e=>{e.hasChanged(71)&&(this.updateDecorations([]),this.stop(),this.computeLinks.schedule(0))}))),this._register(e.onDidChangeModelContent((e=>{this.editor.hasModel()&&this.computeLinks.schedule(this.debounceInformation.get(this.editor.getModel()))}))),this._register(e.onDidChangeModel((e=>{this.currentOccurrences={},this.activeLinkDecorationId=null,this.stop(),this.computeLinks.schedule(0)}))),this._register(e.onDidChangeModelLanguage((e=>{this.stop(),this.computeLinks.schedule(0)}))),this._register(this.providers.onDidChange((e=>{this.stop(),this.computeLinks.schedule(0)}))),this.computeLinks.schedule(0)}async computeLinksNow(){if(!this.editor.hasModel()||!this.editor.getOption(71))return;const e=this.editor.getModel();if(!e.isTooLargeForSyncing()&&this.providers.has(e)){this.activeLinksList&&(this.activeLinksList.dispose(),this.activeLinksList=null),this.computePromise=(0,s.SS)((t=>L(this.providers,e,t)));try{const t=new d.W(!1);if(this.activeLinksList=await this.computePromise,this.debounceInformation.update(e,t.elapsed()),e.isDisposed())return;this.updateDecorations(this.activeLinksList.links)}catch(t){(0,r.dz)(t)}finally{this.computePromise=null}}}updateDecorations(e){const t="altKey"===this.editor.getOption(78),i=[],s=Object.keys(this.currentOccurrences);for(const r of s){const e=this.currentOccurrences[r];i.push(e.decorationId)}const n=[];if(e)for(const r of e)n.push(M.decoration(r,t));this.editor.changeDecorations((t=>{const s=t.deltaDecorations(i,n);this.currentOccurrences={},this.activeLinkDecorationId=null;for(let i=0,n=s.length;i{t.activate(e,i),this.activeLinkDecorationId=t.decorationId}))}else this.cleanUpActiveLinkDecoration()}cleanUpActiveLinkDecoration(){const e="altKey"===this.editor.getOption(78);if(this.activeLinkDecorationId){const t=this.currentOccurrences[this.activeLinkDecorationId];t&&this.editor.changeDecorations((i=>{t.deactivate(i,e)})),this.activeLinkDecorationId=null}}onEditorMouseUp(e){if(!this.isEnabled(e))return;const t=this.getLinkOccurrence(e.target.position);t&&this.openLinkOccurrence(t,e.hasSideBySideModifier,!0)}openLinkOccurrence(e,t,i=!1){if(!this.openerService)return;const{link:s}=e;s.resolve(n.XO.None).then((e=>{if("string"===typeof e&&this.editor.hasModel()){const t=this.editor.getModel().uri;if(t.scheme===l.ny.file&&e.startsWith(`${l.ny.file}:`)){const i=u.r.parse(e);if(i.scheme===l.ny.file){const s=h.su(i);let n=null;s.startsWith("/./")||s.startsWith("\\.\\")?n=`.${s.substr(1)}`:(s.startsWith("//./")||s.startsWith("\\\\.\\"))&&(n=`.${s.substr(2)}`),n&&(e=h.uJ(t,n))}}}return this.openerService.open(e,{openToSide:t,fromUserGesture:i,allowContributedOpeners:!0,allowCommands:!0,fromWorkspace:!0})}),(e=>{const t=e instanceof Error?e.message:e;"invalid"===t?this.notificationService.warn(T.kg("invalid.url","Failed to open this link because it is not well-formed: {0}",s.url.toString())):"missing"===t?this.notificationService.warn(T.kg("missing.url","Failed to open this link because its target is missing.")):(0,r.dz)(e)}))}getLinkOccurrence(e){if(!this.editor.hasModel()||!e)return null;const t=this.editor.getModel().getDecorationsInRange({startLineNumber:e.lineNumber,startColumn:e.column,endLineNumber:e.lineNumber,endColumn:e.column},0,!0);for(const i of t){const e=this.currentOccurrences[i.id];if(e)return e}return null}isEnabled(e,t){return Boolean(6===e.target.type&&(e.hasTriggerModifier||t&&t.keyCodeIsTriggerKey))}stop(){this.computeLinks.cancel(),this.activeLinksList&&(this.activeLinksList?.dispose(),this.activeLinksList=null),this.computePromise&&(this.computePromise.cancel(),this.computePromise=null)}dispose(){super.dispose(),this.stop()}};I=R=A([N(1,k.C),N(2,x.Ot),N(3,f.ILanguageFeaturesService),N(4,m.ILanguageFeatureDebounceService)],I);const O=p.kI.register({description:"detected-link",stickiness:1,collapseOnReplaceEdit:!0,inlineClassName:"detected-link"}),D=p.kI.register({description:"detected-link-active",stickiness:1,collapseOnReplaceEdit:!0,inlineClassName:"detected-link-active"});class M{static decoration(e,t){return{range:e.range,options:M._getOptions(e,t,!1)}}static _getOptions(e,t,i){const s={...i?D:O};return s.hoverMessage=function(e,t){const i=e.url&&/^command:/i.test(e.url.toString()),s=e.tooltip?e.tooltip:i?T.kg("links.navigate.executeCmd","Execute command"):T.kg("links.navigate.follow","Follow link"),n=t?c.zx?T.kg("links.navigate.kb.meta.mac","cmd + click"):T.kg("links.navigate.kb.meta","ctrl + click"):c.zx?T.kg("links.navigate.kb.alt.mac","option + click"):T.kg("links.navigate.kb.alt","alt + click");if(e.url){let t="";if(/^command:/i.test(e.url.toString())){const i=e.url.toString().match(/^command:([^?#]+)/);if(i){const e=i[1];t=T.kg("tooltip.explanation","Execute command {0}",e)}}return new o.Bc("",!0).appendLink(e.url.toString(!0).replace(/ /g,"%20"),s,t).appendMarkdown(` (${n})`)}return(new o.Bc).appendText(`${s} (${n})`)}(e,t),s}constructor(e,t){this.link=e,this.decorationId=t}activate(e,t){e.changeDecorationOptions(this.decorationId,M._getOptions(this.link,t,!0))}deactivate(e,t){e.changeDecorationOptions(this.decorationId,M._getOptions(this.link,t,!1))}}class P extends g.ks{constructor(){super({id:"editor.action.openLink",label:T.kg("label","Open Link"),alias:"Open Link",precondition:void 0})}run(e,t){const i=I.get(t);if(!i)return;if(!t.hasModel())return;const s=t.getSelections();for(const n of s){const e=i.getLinkOccurrence(n.getEndPosition());e&&i.openLinkOccurrence(e,!1)}}}(0,g.HW)(I.ID,I,1),(0,g.Fl)(P)},95200:(e,t,i)=>{"use strict";var s=i(5662),n=i(31450);class r extends s.jG{static{this.ID="editor.contrib.longLinesHelper"}constructor(e){super(),this._editor=e,this._register(this._editor.onMouseDown((e=>{const t=this._editor.getOption(118);t>=0&&6===e.target.type&&e.target.position.column>=t&&this._editor.updateOptions({stopRenderingLineAfter:-1})})))}}(0,n.HW)(r.ID,r,2)},99645:(e,t,i)=>{"use strict";i.d(t,{k:()=>v});var s,n=i(68214),r=i(11007),o=i(41234),a=i(16980),l=i(5662),c=i(31450),h=i(36677),d=i(20492),u=i(78209),g=i(32848),p=i(49099),m=i(8597),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class{static{s=this}static{this.ID="editor.contrib.messageController"}static{this.MESSAGE_VISIBLE=new g.N1("messageVisible",!1,u.kg("messageVisible","Whether the editor is currently showing an inline message"))}static get(e){return e.getContribution(s.ID)}constructor(e,t,i){this._openerService=i,this._messageWidget=new l.HE,this._messageListeners=new l.Cm,this._mouseOverMessage=!1,this._editor=e,this._visible=s.MESSAGE_VISIBLE.bindTo(t)}dispose(){this._message?.dispose(),this._messageListeners.dispose(),this._messageWidget.dispose(),this._visible.reset()}showMessage(e,t){let i;(0,r.xE)((0,a.VS)(e)?e.value:e),this._visible.set(!0),this._messageWidget.clear(),this._messageListeners.clear(),this._message=(0,a.VS)(e)?(0,n.Gc)(e,{actionHandler:{callback:t=>{this.closeMessage(),(0,d.i)(this._openerService,t,(0,a.VS)(e)?e.isTrusted:void 0)},disposables:this._messageListeners}}):void 0,this._messageWidget.value=new b(this._editor,t,"string"===typeof e?e:this._message.element),this._messageListeners.add(o.Jh.debounce(this._editor.onDidBlurEditorText,((e,t)=>t),0)((()=>{this._mouseOverMessage||this._messageWidget.value&&m.QX(m.bq(),this._messageWidget.value.getDomNode())||this.closeMessage()}))),this._messageListeners.add(this._editor.onDidChangeCursorPosition((()=>this.closeMessage()))),this._messageListeners.add(this._editor.onDidDispose((()=>this.closeMessage()))),this._messageListeners.add(this._editor.onDidChangeModel((()=>this.closeMessage()))),this._messageListeners.add(m.ko(this._messageWidget.value.getDomNode(),m.Bx.MOUSE_ENTER,(()=>this._mouseOverMessage=!0),!0)),this._messageListeners.add(m.ko(this._messageWidget.value.getDomNode(),m.Bx.MOUSE_LEAVE,(()=>this._mouseOverMessage=!1),!0)),this._messageListeners.add(this._editor.onMouseMove((e=>{e.target.position&&(i?i.containsPosition(e.target.position)||this.closeMessage():i=new h.Q(t.lineNumber-3,1,e.target.position.lineNumber+3,1))})))}closeMessage(){this._visible.reset(),this._messageListeners.clear(),this._messageWidget.value&&this._messageListeners.add(b.fadeOut(this._messageWidget.value))}};v=s=f([_(1,g.fN),_(2,p.C)],v);const C=c.DX.bindToContribution(v.get);(0,c.E_)(new C({id:"leaveEditorMessage",precondition:v.MESSAGE_VISIBLE,handler:e=>e.closeMessage(),kbOpts:{weight:130,primary:9}}));class b{static fadeOut(e){const t=()=>{e.dispose(),clearTimeout(i),e.getDomNode().removeEventListener("animationend",t)},i=setTimeout(t,110);return e.getDomNode().addEventListener("animationend",t),e.getDomNode().classList.add("fadeOut"),{dispose:t}}constructor(e,{lineNumber:t,column:i},s){this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this._editor=e,this._editor.revealLinesInCenterIfOutsideViewport(t,t,0),this._position={lineNumber:t,column:i},this._domNode=document.createElement("div"),this._domNode.classList.add("monaco-editor-overlaymessage"),this._domNode.style.marginLeft="-6px";const n=document.createElement("div");n.classList.add("anchor","top"),this._domNode.appendChild(n);const r=document.createElement("div");"string"===typeof s?(r.classList.add("message"),r.textContent=s):(s.classList.add("message"),r.appendChild(s)),this._domNode.appendChild(r);const o=document.createElement("div");o.classList.add("anchor","below"),this._domNode.appendChild(o),this._editor.addContentWidget(this),this._domNode.classList.add("fadeIn")}dispose(){this._editor.removeContentWidget(this)}getId(){return"messageoverlay"}getDomNode(){return this._domNode}getPosition(){return{position:this._position,preference:[1,2],positionAffinity:1}}afterRender(e){this._domNode.classList.toggle("below",2===e)}}(0,c.HW)(v.ID,v,4)},50352:(e,t,i)=>{"use strict";var s,n=i(11007),r=i(90766),o=i(24939),a=i(5662),l=i(31450),c=i(50672),h=i(36677),d=i(75326),u=i(60002),g=i(34175),p=i(78209),m=i(27195),f=i(32848),_=i(56942),v=i(13864),C=i(63591),b=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},E=function(e,t){return function(i,s){t(i,s,e)}};function S(e,t){const i=t.filter((t=>!e.find((e=>e.equals(t)))));if(i.length>=1){const e=i.map((e=>`line ${e.viewState.position.lineNumber} column ${e.viewState.position.column}`)).join(", "),t=1===i.length?p.kg("cursorAdded","Cursor added: {0}",e):p.kg("cursorsAdded","Cursors added: {0}",e);(0,n.h5)(t)}}class y extends l.ks{constructor(){super({id:"editor.action.insertCursorAbove",label:p.kg("mutlicursor.insertAbove","Add Cursor Above"),alias:"Add Cursor Above",precondition:void 0,kbOpts:{kbExpr:u.R.editorTextFocus,primary:2576,linux:{primary:1552,secondary:[3088]},weight:100},menuOpts:{menuId:m.D8.MenubarSelectionMenu,group:"3_multi",title:p.kg({key:"miInsertCursorAbove",comment:["&& denotes a mnemonic"]},"&&Add Cursor Above"),order:2}})}run(e,t,i){if(!t.hasModel())return;let s=!0;i&&!1===i.logicalLine&&(s=!1);const n=t._getViewModel();if(n.cursorConfig.readOnly)return;n.model.pushStackElement();const r=n.getCursorStates();n.setCursorStates(i.source,3,c.c.addCursorUp(n,r,s)),n.revealTopMostCursor(i.source),S(r,n.getCursorStates())}}class w extends l.ks{constructor(){super({id:"editor.action.insertCursorBelow",label:p.kg("mutlicursor.insertBelow","Add Cursor Below"),alias:"Add Cursor Below",precondition:void 0,kbOpts:{kbExpr:u.R.editorTextFocus,primary:2578,linux:{primary:1554,secondary:[3090]},weight:100},menuOpts:{menuId:m.D8.MenubarSelectionMenu,group:"3_multi",title:p.kg({key:"miInsertCursorBelow",comment:["&& denotes a mnemonic"]},"A&&dd Cursor Below"),order:3}})}run(e,t,i){if(!t.hasModel())return;let s=!0;i&&!1===i.logicalLine&&(s=!1);const n=t._getViewModel();if(n.cursorConfig.readOnly)return;n.model.pushStackElement();const r=n.getCursorStates();n.setCursorStates(i.source,3,c.c.addCursorDown(n,r,s)),n.revealBottomMostCursor(i.source),S(r,n.getCursorStates())}}class L extends l.ks{constructor(){super({id:"editor.action.insertCursorAtEndOfEachLineSelected",label:p.kg("mutlicursor.insertAtEndOfEachLineSelected","Add Cursors to Line Ends"),alias:"Add Cursors to Line Ends",precondition:void 0,kbOpts:{kbExpr:u.R.editorTextFocus,primary:1575,weight:100},menuOpts:{menuId:m.D8.MenubarSelectionMenu,group:"3_multi",title:p.kg({key:"miInsertCursorAtEndOfEachLineSelected",comment:["&& denotes a mnemonic"]},"Add C&&ursors to Line Ends"),order:4}})}getCursorsForSelection(e,t,i){if(!e.isEmpty()){for(let s=e.startLineNumber;s1&&i.push(new d.L(e.endLineNumber,e.endColumn,e.endLineNumber,e.endColumn))}}run(e,t){if(!t.hasModel())return;const i=t.getModel(),s=t.getSelections(),n=t._getViewModel(),r=n.getCursorStates(),o=[];s.forEach((e=>this.getCursorsForSelection(e,i,o))),o.length>0&&t.setSelections(o),S(r,n.getCursorStates())}}class R extends l.ks{constructor(){super({id:"editor.action.addCursorsToBottom",label:p.kg("mutlicursor.addCursorsToBottom","Add Cursors To Bottom"),alias:"Add Cursors To Bottom",precondition:void 0})}run(e,t){if(!t.hasModel())return;const i=t.getSelections(),s=t.getModel().getLineCount(),n=[];for(let a=i[0].startLineNumber;a<=s;a++)n.push(new d.L(a,i[0].startColumn,a,i[0].endColumn));const r=t._getViewModel(),o=r.getCursorStates();n.length>0&&t.setSelections(n),S(o,r.getCursorStates())}}class T extends l.ks{constructor(){super({id:"editor.action.addCursorsToTop",label:p.kg("mutlicursor.addCursorsToTop","Add Cursors To Top"),alias:"Add Cursors To Top",precondition:void 0})}run(e,t){if(!t.hasModel())return;const i=t.getSelections(),s=[];for(let o=i[0].startLineNumber;o>=1;o--)s.push(new d.L(o,i[0].startColumn,o,i[0].endColumn));const n=t._getViewModel(),r=n.getCursorStates();s.length>0&&t.setSelections(s),S(r,n.getCursorStates())}}class x{constructor(e,t,i){this.selections=e,this.revealRange=t,this.revealScrollType=i}}class k{static create(e,t){if(!e.hasModel())return null;const i=t.getState();if(!e.hasTextFocus()&&i.isRevealed&&i.searchString.length>0)return new k(e,t,!1,i.searchString,i.wholeWord,i.matchCase,null);let s,n,r=!1;const o=e.getSelections();1===o.length&&o[0].isEmpty()?(r=!0,s=!0,n=!0):(s=i.wholeWord,n=i.matchCase);const a=e.getSelection();let l,c=null;if(a.isEmpty()){const t=e.getConfiguredWordAtPosition(a.getStartPosition());if(!t)return null;l=t.word,c=new d.L(a.startLineNumber,t.startColumn,a.startLineNumber,t.endColumn)}else l=e.getModel().getValueInRange(a).replace(/\r\n/g,"\n");return new k(e,t,r,l,s,n,c)}constructor(e,t,i,s,n,r,o){this._editor=e,this.findController=t,this.isDisconnectedFromFindController=i,this.searchText=s,this.wholeWord=n,this.matchCase=r,this.currentMatch=o}addSelectionToNextFindMatch(){if(!this._editor.hasModel())return null;const e=this._getNextMatch();if(!e)return null;const t=this._editor.getSelections();return new x(t.concat(e),e,0)}moveSelectionToNextFindMatch(){if(!this._editor.hasModel())return null;const e=this._getNextMatch();if(!e)return null;const t=this._editor.getSelections();return new x(t.slice(0,t.length-1).concat(e),e,0)}_getNextMatch(){if(!this._editor.hasModel())return null;if(this.currentMatch){const e=this.currentMatch;return this.currentMatch=null,e}this.findController.highlightFindOptions();const e=this._editor.getSelections(),t=e[e.length-1],i=this._editor.getModel().findNextMatch(this.searchText,t.getEndPosition(),!1,this.matchCase,this.wholeWord?this._editor.getOption(132):null,!1);return i?new d.L(i.range.startLineNumber,i.range.startColumn,i.range.endLineNumber,i.range.endColumn):null}addSelectionToPreviousFindMatch(){if(!this._editor.hasModel())return null;const e=this._getPreviousMatch();if(!e)return null;const t=this._editor.getSelections();return new x(t.concat(e),e,0)}moveSelectionToPreviousFindMatch(){if(!this._editor.hasModel())return null;const e=this._getPreviousMatch();if(!e)return null;const t=this._editor.getSelections();return new x(t.slice(0,t.length-1).concat(e),e,0)}_getPreviousMatch(){if(!this._editor.hasModel())return null;if(this.currentMatch){const e=this.currentMatch;return this.currentMatch=null,e}this.findController.highlightFindOptions();const e=this._editor.getSelections(),t=e[e.length-1],i=this._editor.getModel().findPreviousMatch(this.searchText,t.getStartPosition(),!1,this.matchCase,this.wholeWord?this._editor.getOption(132):null,!1);return i?new d.L(i.range.startLineNumber,i.range.startColumn,i.range.endLineNumber,i.range.endColumn):null}selectAll(e){if(!this._editor.hasModel())return[];this.findController.highlightFindOptions();const t=this._editor.getModel();return e?t.findMatches(this.searchText,e,!1,this.matchCase,this.wholeWord?this._editor.getOption(132):null,!1,1073741824):t.findMatches(this.searchText,!0,!1,this.matchCase,this.wholeWord?this._editor.getOption(132):null,!1,1073741824)}}class A extends a.jG{static{this.ID="editor.contrib.multiCursorController"}static get(e){return e.getContribution(A.ID)}constructor(e){super(),this._sessionDispose=this._register(new a.Cm),this._editor=e,this._ignoreSelectionChange=!1,this._session=null}dispose(){this._endSession(),super.dispose()}_beginSessionIfNeeded(e){if(!this._session){const t=k.create(this._editor,e);if(!t)return;this._session=t;const i={searchString:this._session.searchText};this._session.isDisconnectedFromFindController&&(i.wholeWordOverride=1,i.matchCaseOverride=1,i.isRegexOverride=2),e.getState().change(i,!1),this._sessionDispose.add(this._editor.onDidChangeCursorSelection((e=>{this._ignoreSelectionChange||this._endSession()}))),this._sessionDispose.add(this._editor.onDidBlurEditorText((()=>{this._endSession()}))),this._sessionDispose.add(e.getState().onFindReplaceStateChange((e=>{(e.matchCase||e.wholeWord)&&this._endSession()})))}}_endSession(){if(this._sessionDispose.clear(),this._session&&this._session.isDisconnectedFromFindController){const e={wholeWordOverride:0,matchCaseOverride:0,isRegexOverride:0};this._session.findController.getState().change(e,!1)}this._session=null}_setSelections(e){this._ignoreSelectionChange=!0,this._editor.setSelections(e),this._ignoreSelectionChange=!1}_expandEmptyToWord(e,t){if(!t.isEmpty())return t;const i=this._editor.getConfiguredWordAtPosition(t.getStartPosition());return i?new d.L(t.startLineNumber,i.startColumn,t.startLineNumber,i.endColumn):t}_applySessionResult(e){e&&(this._setSelections(e.selections),e.revealRange&&this._editor.revealRangeInCenterIfOutsideViewport(e.revealRange,e.revealScrollType))}getSession(e){return this._session}addSelectionToNextFindMatch(e){if(this._editor.hasModel()){if(!this._session){const t=this._editor.getSelections();if(t.length>1){const i=e.getState().matchCase;if(!D(this._editor.getModel(),t,i)){const e=this._editor.getModel(),i=[];for(let s=0,n=t.length;s0&&i.isRegex){const e=this._editor.getModel();t=i.searchScope?e.findMatches(i.searchString,i.searchScope,i.isRegex,i.matchCase,i.wholeWord?this._editor.getOption(132):null,!1,1073741824):e.findMatches(i.searchString,!0,i.isRegex,i.matchCase,i.wholeWord?this._editor.getOption(132):null,!1,1073741824)}else{if(this._beginSessionIfNeeded(e),!this._session)return;t=this._session.selectAll(i.searchScope)}if(t.length>0){const e=this._editor.getSelection();for(let i=0,s=t.length;inew d.L(e.range.startLineNumber,e.range.startColumn,e.range.endLineNumber,e.range.endColumn))))}}}class N extends l.ks{run(e,t){const i=A.get(t);if(!i)return;const s=t._getViewModel();if(s){const n=s.getCursorStates(),r=g.z0.get(t);if(r)this._run(i,r);else{const s=e.get(C._Y).createInstance(g.z0,t);this._run(i,s),s.dispose()}S(n,s.getCursorStates())}}}class I{constructor(e,t,i,s,n){this._model=e,this._searchText=t,this._matchCase=i,this._wordSeparators=s,this._modelVersionId=this._model.getVersionId(),this._cachedFindMatches=null,n&&this._model===n._model&&this._searchText===n._searchText&&this._matchCase===n._matchCase&&this._wordSeparators===n._wordSeparators&&this._modelVersionId===n._modelVersionId&&(this._cachedFindMatches=n._cachedFindMatches)}findMatches(){return null===this._cachedFindMatches&&(this._cachedFindMatches=this._model.findMatches(this._searchText,!0,!1,this._matchCase,this._wordSeparators,!1).map((e=>e.range)),this._cachedFindMatches.sort(h.Q.compareRangesUsingStarts)),this._cachedFindMatches}}let O=class extends a.jG{static{s=this}static{this.ID="editor.contrib.selectionHighlighter"}constructor(e,t){super(),this._languageFeaturesService=t,this.editor=e,this._isEnabled=e.getOption(109),this._decorations=e.createDecorationsCollection(),this.updateSoon=this._register(new r.uC((()=>this._update()),300)),this.state=null,this._register(e.onDidChangeConfiguration((t=>{this._isEnabled=e.getOption(109)}))),this._register(e.onDidChangeCursorSelection((e=>{this._isEnabled&&(e.selection.isEmpty()?3===e.reason?(this.state&&this._setState(null),this.updateSoon.schedule()):this._setState(null):this._update())}))),this._register(e.onDidChangeModel((e=>{this._setState(null)}))),this._register(e.onDidChangeModelContent((e=>{this._isEnabled&&this.updateSoon.schedule()})));const i=g.z0.get(e);i&&this._register(i.getState().onFindReplaceStateChange((e=>{this._update()}))),this.updateSoon.schedule()}_update(){this._setState(s._createState(this.state,this._isEnabled,this.editor))}static _createState(e,t,i){if(!t)return null;if(!i.hasModel())return null;const s=i.getSelection();if(s.startLineNumber!==s.endLineNumber)return null;const n=A.get(i);if(!n)return null;const r=g.z0.get(i);if(!r)return null;let o=n.getSession(r);if(!o){const e=i.getSelections();if(e.length>1){const t=r.getState().matchCase;if(!D(i.getModel(),e,t))return null}o=k.create(i,r)}if(!o)return null;if(o.currentMatch)return null;if(/^[ \t]+$/.test(o.searchText))return null;if(o.searchText.length>200)return null;const a=r.getState(),l=a.matchCase;if(a.isRevealed){let e=a.searchString;l||(e=e.toLowerCase());let t=o.searchText;if(l||(t=t.toLowerCase()),e===t&&o.matchCase===a.matchCase&&o.wholeWord===a.wholeWord&&!a.isRegex)return null}return new I(i.getModel(),o.searchText,o.matchCase,o.wholeWord?i.getOption(132):null,e)}_setState(e){if(this.state=e,!this.state)return void this._decorations.clear();if(!this.editor.hasModel())return;const t=this.editor.getModel();if(t.isTooLargeForTokenization())return;const i=this.state.findMatches(),s=this.editor.getSelections();s.sort(h.Q.compareRangesUsingStarts);const n=[];for(let l=0,c=0,d=i.length,u=s.length;l=u)n.push(e),l++;else{const t=h.Q.compareRangesUsingStarts(e,s[c]);t<0?(!s[c].isEmpty()&&h.Q.areIntersecting(e,s[c])||n.push(e),l++):(t>0||l++,c++)}}const r="off"!==this.editor.getOption(81),o=this._languageFeaturesService.documentHighlightProvider.has(t)&&r,a=n.map((e=>({range:e,options:(0,v.v)(o)})));this._decorations.set(a)}dispose(){this._setState(null),super.dispose()}};function D(e,t,i){const s=M(e,t[0],!i);for(let n=1,r=t.length;n{"use strict";var s=i(91090),n=i(5662),r=i(31450),o=i(60002),a=i(62083),l=i(56942),c=i(90766),h=i(64383),d=i(41234),u=i(60534),g=i(18447),p=i(631),m=i(79400),f=i(83069),_=i(18938),v=i(50091),C=i(32848);const b={Visible:new C.N1("parameterHintsVisible",!1),MultipleSignatures:new C.N1("parameterHintsMultipleSignatures",!1)};async function E(e,t,i,s,n){const r=e.ordered(t);for(const a of r)try{const e=await a.provideSignatureHelp(t,i,n,s);if(e)return e}catch(o){(0,h.M_)(o)}}var S;v.w.registerCommand("_executeSignatureHelpProvider",(async(e,...t)=>{const[i,s,n]=t;(0,p.j)(m.r.isUri(i)),(0,p.j)(f.y.isIPosition(s)),(0,p.j)("string"===typeof n||!n);const r=e.get(l.ILanguageFeaturesService),o=await e.get(_.ITextModelService).createModelReference(i);try{const e=await E(r.signatureHelpProvider,o.object.textEditorModel,f.y.lift(s),{triggerKind:a.WA.Invoke,isRetrigger:!1,triggerCharacter:n},g.XO.None);if(!e)return;return setTimeout((()=>e.dispose()),0),e.value}finally{o.dispose()}})),function(e){e.Default={type:0};e.Pending=class{constructor(e,t){this.request=e,this.previouslyActiveHints=t,this.type=2}};e.Active=class{constructor(e){this.hints=e,this.type=1}}}(S||(S={}));class y extends n.jG{static{this.DEFAULT_DELAY=120}constructor(e,t,i=y.DEFAULT_DELAY){super(),this._onChangedHints=this._register(new d.vl),this.onChangedHints=this._onChangedHints.event,this.triggerOnType=!1,this._state=S.Default,this._pendingTriggers=[],this._lastSignatureHelpResult=this._register(new n.HE),this.triggerChars=new u.y,this.retriggerChars=new u.y,this.triggerId=0,this.editor=e,this.providers=t,this.throttledDelayer=new c.ve(i),this._register(this.editor.onDidBlurEditorWidget((()=>this.cancel()))),this._register(this.editor.onDidChangeConfiguration((()=>this.onEditorConfigurationChange()))),this._register(this.editor.onDidChangeModel((e=>this.onModelChanged()))),this._register(this.editor.onDidChangeModelLanguage((e=>this.onModelChanged()))),this._register(this.editor.onDidChangeCursorSelection((e=>this.onCursorChange(e)))),this._register(this.editor.onDidChangeModelContent((e=>this.onModelContentChange()))),this._register(this.providers.onDidChange(this.onModelChanged,this)),this._register(this.editor.onDidType((e=>this.onDidType(e)))),this.onEditorConfigurationChange(),this.onModelChanged()}get state(){return this._state}set state(e){2===this._state.type&&this._state.request.cancel(),this._state=e}cancel(e=!1){this.state=S.Default,this.throttledDelayer.cancel(),e||this._onChangedHints.fire(void 0)}trigger(e,t){const i=this.editor.getModel();if(!i||!this.providers.has(i))return;const s=++this.triggerId;this._pendingTriggers.push(e),this.throttledDelayer.trigger((()=>this.doTrigger(s)),t).catch(h.dz)}next(){if(1!==this.state.type)return;const e=this.state.hints.signatures.length,t=this.state.hints.activeSignature,i=t%e===e-1,s=this.editor.getOption(86).cycle;!(e<2||i)||s?this.updateActiveSignature(i&&s?0:t+1):this.cancel()}previous(){if(1!==this.state.type)return;const e=this.state.hints.signatures.length,t=this.state.hints.activeSignature,i=0===t,s=this.editor.getOption(86).cycle;!(e<2||i)||s?this.updateActiveSignature(i&&s?e-1:t-1):this.cancel()}updateActiveSignature(e){1===this.state.type&&(this.state=new S.Active({...this.state.hints,activeSignature:e}),this._onChangedHints.fire(this.state.hints))}async doTrigger(e){const t=1===this.state.type||2===this.state.type,i=this.getLastActiveHints();if(this.cancel(!0),0===this._pendingTriggers.length)return!1;const s=this._pendingTriggers.reduce(w);this._pendingTriggers=[];const n={triggerKind:s.triggerKind,triggerCharacter:s.triggerCharacter,isRetrigger:t,activeSignatureHelp:i};if(!this.editor.hasModel())return!1;const r=this.editor.getModel(),o=this.editor.getPosition();this.state=new S.Pending((0,c.SS)((e=>E(this.providers,r,o,n,e))),i);try{const t=await this.state.request;return e!==this.triggerId?(t?.dispose(),!1):t&&t.value.signatures&&0!==t.value.signatures.length?(this.state=new S.Active(t.value),this._lastSignatureHelpResult.value=t,this._onChangedHints.fire(this.state.hints),!0):(t?.dispose(),this._lastSignatureHelpResult.clear(),this.cancel(),!1)}catch(a){return e===this.triggerId&&(this.state=S.Default),(0,h.dz)(a),!1}}getLastActiveHints(){switch(this.state.type){case 1:return this.state.hints;case 2:return this.state.previouslyActiveHints;default:return}}get isTriggered(){return 1===this.state.type||2===this.state.type||this.throttledDelayer.isTriggered()}onModelChanged(){this.cancel(),this.triggerChars.clear(),this.retriggerChars.clear();const e=this.editor.getModel();if(e)for(const t of this.providers.ordered(e)){for(const e of t.signatureHelpTriggerCharacters||[])if(e.length){const t=e.charCodeAt(0);this.triggerChars.add(t),this.retriggerChars.add(t)}for(const e of t.signatureHelpRetriggerCharacters||[])e.length&&this.retriggerChars.add(e.charCodeAt(0))}}onDidType(e){if(!this.triggerOnType)return;const t=e.length-1,i=e.charCodeAt(t);(this.triggerChars.has(i)||this.isTriggered&&this.retriggerChars.has(i))&&this.trigger({triggerKind:a.WA.TriggerCharacter,triggerCharacter:e.charAt(t)})}onCursorChange(e){"mouse"===e.source?this.cancel():this.isTriggered&&this.trigger({triggerKind:a.WA.ContentChange})}onModelContentChange(){this.isTriggered&&this.trigger({triggerKind:a.WA.ContentChange})}onEditorConfigurationChange(){this.triggerOnType=this.editor.getOption(86).enabled,this.triggerOnType||this.cancel()}dispose(){this.cancel(!0),super.dispose()}}function w(e,t){switch(t.triggerKind){case a.WA.Invoke:return t;case a.WA.ContentChange:return e;case a.WA.TriggerCharacter:default:return t}}var L,R=i(78209),T=i(63591),x=i(8597),k=i(11007),A=i(31295),N=i(10350),I=i(91508),O=i(87908),D=i(10154),M=i(20492),P=i(49099),F=i(66261),U=i(61394),H=i(25689),B=i(78381),W=i(90651),V=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};const G=x.$,j=(0,U.pU)("parameter-hints-next",N.W.chevronDown,R.kg("parameterHintsNextIcon","Icon for show next parameter hint.")),K=(0,U.pU)("parameter-hints-previous",N.W.chevronUp,R.kg("parameterHintsPreviousIcon","Icon for show previous parameter hint."));let Y=class extends n.jG{static{L=this}static{this.ID="editor.widget.parameterHintsWidget"}constructor(e,t,i,s,r,o){super(),this.editor=e,this.model=t,this.telemetryService=o,this.renderDisposeables=this._register(new n.Cm),this.visible=!1,this.announcedLabel=null,this.allowEditorOverflow=!0,this.markdownRenderer=this._register(new M.T({editor:e},r,s)),this.keyVisible=b.Visible.bindTo(i),this.keyMultipleSignatures=b.MultipleSignatures.bindTo(i)}createParameterHintDOMNodes(){const e=G(".editor-widget.parameter-hints-widget"),t=x.BC(e,G(".phwrapper"));t.tabIndex=-1;const i=x.BC(t,G(".controls")),s=x.BC(i,G(".button"+H.L.asCSSSelector(K))),n=x.BC(i,G(".overloads")),r=x.BC(i,G(".button"+H.L.asCSSSelector(j)));this._register(x.ko(s,"click",(e=>{x.fs.stop(e),this.previous()}))),this._register(x.ko(r,"click",(e=>{x.fs.stop(e),this.next()})));const o=G(".body"),a=new A.MU(o,{alwaysConsumeMouseWheel:!0});this._register(a),t.appendChild(a.getDomNode());const l=x.BC(o,G(".signature")),c=x.BC(o,G(".docs"));e.style.userSelect="text",this.domNodes={element:e,signature:l,overloads:n,docs:c,scrollbar:a},this.editor.addContentWidget(this),this.hide(),this._register(this.editor.onDidChangeCursorSelection((e=>{this.visible&&this.editor.layoutContentWidget(this)})));const h=()=>{if(!this.domNodes)return;const e=this.editor.getOption(50),t=this.domNodes.element;t.style.fontSize=`${e.fontSize}px`,t.style.lineHeight=""+e.lineHeight/e.fontSize,t.style.setProperty("--vscode-parameterHintsWidget-editorFontFamily",e.fontFamily),t.style.setProperty("--vscode-parameterHintsWidget-editorFontFamilyDefault",O.jU.fontFamily)};h(),this._register(d.Jh.chain(this.editor.onDidChangeConfiguration.bind(this.editor),(e=>e.filter((e=>e.hasChanged(50)))))(h)),this._register(this.editor.onDidLayoutChange((e=>this.updateMaxHeight()))),this.updateMaxHeight()}show(){this.visible||(this.domNodes||this.createParameterHintDOMNodes(),this.keyVisible.set(!0),this.visible=!0,setTimeout((()=>{this.domNodes?.element.classList.add("visible")}),100),this.editor.layoutContentWidget(this))}hide(){this.renderDisposeables.clear(),this.visible&&(this.keyVisible.reset(),this.visible=!1,this.announcedLabel=null,this.domNodes?.element.classList.remove("visible"),this.editor.layoutContentWidget(this))}getPosition(){return this.visible?{position:this.editor.getPosition(),preference:[1,2]}:null}render(e){if(this.renderDisposeables.clear(),!this.domNodes)return;const t=e.signatures.length>1;this.domNodes.element.classList.toggle("multiple",t),this.keyMultipleSignatures.set(t),this.domNodes.signature.innerText="",this.domNodes.docs.innerText="";const i=e.signatures[e.activeSignature];if(!i)return;const s=x.BC(this.domNodes.signature,G(".code")),n=i.parameters.length>0,r=i.activeParameter??e.activeParameter;if(n)this.renderParameters(s,i,r);else{x.BC(s,G("span")).textContent=i.label}const o=i.parameters[r];if(o?.documentation){const e=G("span.documentation");if("string"===typeof o.documentation)e.textContent=o.documentation;else{const t=this.renderMarkdownDocs(o.documentation);e.appendChild(t.element)}x.BC(this.domNodes.docs,G("p",{},e))}if(void 0===i.documentation);else if("string"===typeof i.documentation)x.BC(this.domNodes.docs,G("p",{},i.documentation));else{const e=this.renderMarkdownDocs(i.documentation);x.BC(this.domNodes.docs,e.element)}const a=this.hasDocs(i,o);if(this.domNodes.signature.classList.toggle("has-docs",a),this.domNodes.docs.classList.toggle("empty",!a),this.domNodes.overloads.textContent=String(e.activeSignature+1).padStart(e.signatures.length.toString().length,"0")+"/"+e.signatures.length,o){let e="";const t=i.parameters[r];e=Array.isArray(t.label)?i.label.substring(t.label[0],t.label[1]):t.label,t.documentation&&(e+="string"===typeof t.documentation?`, ${t.documentation}`:`, ${t.documentation.value}`),i.documentation&&(e+="string"===typeof i.documentation?`, ${i.documentation}`:`, ${i.documentation.value}`),this.announcedLabel!==e&&(k.xE(R.kg("hint","{0}, hint",e)),this.announcedLabel=e)}this.editor.layoutContentWidget(this),this.domNodes.scrollbar.scanDomNode()}renderMarkdownDocs(e){const t=new B.W,i=this.renderDisposeables.add(this.markdownRenderer.render(e,{asyncRenderCallback:()=>{this.domNodes?.scrollbar.scanDomNode()}}));i.element.classList.add("markdown-docs");const s=t.elapsed();return s>300&&this.telemetryService.publicLog2("parameterHints.parseMarkdown",{renderDuration:s}),i}hasDocs(e,t){return!!(t&&"string"===typeof t.documentation&&(0,p.eU)(t.documentation).length>0)||(!!(t&&"object"===typeof t.documentation&&(0,p.eU)(t.documentation).value.length>0)||(!!(e.documentation&&"string"===typeof e.documentation&&(0,p.eU)(e.documentation).length>0)||!!(e.documentation&&"object"===typeof e.documentation&&(0,p.eU)(e.documentation.value).length>0)))}renderParameters(e,t,i){const[s,n]=this.getParameterLabelOffsets(t,i),r=document.createElement("span");r.textContent=t.label.substring(0,s);const o=document.createElement("span");o.textContent=t.label.substring(s,n),o.className="parameter active";const a=document.createElement("span");a.textContent=t.label.substring(n),x.BC(e,r,o,a)}getParameterLabelOffsets(e,t){const i=e.parameters[t];if(i){if(Array.isArray(i.label))return i.label;if(i.label.length){const t=new RegExp(`(\\W|^)${(0,I.bm)(i.label)}(?=\\W|$)`,"g");t.test(e.label);const s=t.lastIndex-i.label.length;return s>=0?[s,t.lastIndex]:[0,0]}return[0,0]}return[0,0]}next(){this.editor.focus(),this.model.next()}previous(){this.editor.focus(),this.model.previous()}getDomNode(){return this.domNodes||this.createParameterHintDOMNodes(),this.domNodes.element}getId(){return L.ID}updateMaxHeight(){if(!this.domNodes)return;const e=`${Math.max(this.editor.getLayoutInfo().height/4,250)}px`;this.domNodes.element.style.maxHeight=e;const t=this.domNodes.element.getElementsByClassName("phwrapper");t.length&&(t[0].style.maxHeight=e)}};Y=L=V([z(2,C.fN),z(3,P.C),z(4,D.L),z(5,W.k)],Y),(0,F.x1A)("editorHoverWidget.highlightForeground",F.QI5,R.kg("editorHoverWidgetHighlightForeground","Foreground color of the active item in the parameter hint."));var q,$=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Q=function(e,t){return function(i,s){t(i,s,e)}};let X=class extends n.jG{static{q=this}static{this.ID="editor.controller.parameterHints"}static get(e){return e.getContribution(q.ID)}constructor(e,t,i){super(),this.editor=e,this.model=this._register(new y(e,i.signatureHelpProvider)),this._register(this.model.onChangedHints((e=>{e?(this.widget.value.show(),this.widget.value.render(e)):this.widget.rawValue?.hide()}))),this.widget=new s.d((()=>this._register(t.createInstance(Y,this.editor,this.model))))}cancel(){this.model.cancel()}previous(){this.widget.rawValue?.previous()}next(){this.widget.rawValue?.next()}trigger(e){this.model.trigger(e,0)}};X=q=$([Q(1,T._Y),Q(2,l.ILanguageFeaturesService)],X);class Z extends r.ks{constructor(){super({id:"editor.action.triggerParameterHints",label:R.kg("parameterHints.trigger.label","Trigger Parameter Hints"),alias:"Trigger Parameter Hints",precondition:o.R.hasSignatureHelpProvider,kbOpts:{kbExpr:o.R.editorTextFocus,primary:3082,weight:100}})}run(e,t){const i=X.get(t);i?.trigger({triggerKind:a.WA.Invoke})}}(0,r.HW)(X.ID,X,2),(0,r.Fl)(Z);const J=r.DX.bindToContribution(X.get);(0,r.E_)(new J({id:"closeParameterHints",precondition:b.Visible,handler:e=>e.cancel(),kbOpts:{weight:175,kbExpr:o.R.focus,primary:9,secondary:[1033]}})),(0,r.E_)(new J({id:"showPrevParameterHint",precondition:C.M$.and(b.Visible,b.MultipleSignatures),handler:e=>e.previous(),kbOpts:{weight:175,kbExpr:o.R.focus,primary:16,secondary:[528],mac:{primary:16,secondary:[528,302]}}})),(0,r.E_)(new J({id:"showNextParameterHint",precondition:C.M$.and(b.Visible,b.MultipleSignatures),handler:e=>e.next(),kbOpts:{weight:175,kbExpr:o.R.focus,primary:18,secondary:[530],mac:{primary:18,secondary:[530,300]}}}))},84226:(e,t,i)=>{"use strict";i.d(t,{zn:()=>O,x2:()=>D,j6:()=>U,RL:()=>P,zl:()=>V,n6:()=>z,z0:()=>H,_X:()=>B,e3:()=>W});var s=i(8597),n=i(11799),r=i(36921),o=i(10350),a=i(25689),l=i(47661),c=i(41234),h=i(10146),d=i(31450),u=i(80301),g=i(29163),p=i(92403),m=i(96032),f=i(5662),_=i(36677),v=i(87289);const C=new l.Q1(new l.bU(0,122,204)),b={showArrow:!0,showFrame:!0,className:"",frameColor:C,arrowColor:C,keepEditorSelection:!1};class E{constructor(e,t,i,s,n,r,o,a){this.id="",this.domNode=e,this.afterLineNumber=t,this.afterColumn=i,this.heightInLines=s,this.showInHiddenAreas=o,this.ordinal=a,this._onDomNodeTop=n,this._onComputedHeight=r}onDomNodeTop(e){this._onDomNodeTop(e)}onComputedHeight(e){this._onComputedHeight(e)}}class S{constructor(e,t){this._id=e,this._domNode=t}getId(){return this._id}getDomNode(){return this._domNode}getPosition(){return null}}class y{static{this._IdGenerator=new m.n(".arrow-decoration-")}constructor(e){this._editor=e,this._ruleName=y._IdGenerator.nextId(),this._decorations=this._editor.createDecorationsCollection(),this._color=null,this._height=-1}dispose(){this.hide(),s.U2(this._ruleName)}set color(e){this._color!==e&&(this._color=e,this._updateStyle())}set height(e){this._height!==e&&(this._height=e,this._updateStyle())}_updateStyle(){s.U2(this._ruleName),s.Wt(`.monaco-editor ${this._ruleName}`,`border-style: solid; border-color: transparent; border-bottom-color: ${this._color}; border-width: ${this._height}px; bottom: -${this._height}px !important; margin-left: -${this._height}px; `)}show(e){1===e.column&&(e={lineNumber:e.lineNumber,column:2}),this._decorations.set([{range:_.Q.fromPositions(e),options:{description:"zone-widget-arrow",className:this._ruleName,stickiness:1}}])}hide(){this._decorations.clear()}}class w{constructor(e,t={}){this._arrow=null,this._overlayWidget=null,this._resizeSash=null,this._viewZone=null,this._disposables=new f.Cm,this.container=null,this._isShowing=!1,this.editor=e,this._positionMarkerId=this.editor.createDecorationsCollection(),this.options=h.Go(t),h.co(this.options,b,!1),this.domNode=document.createElement("div"),this.options.isAccessible||(this.domNode.setAttribute("aria-hidden","true"),this.domNode.setAttribute("role","presentation")),this._disposables.add(this.editor.onDidLayoutChange((e=>{const t=this._getWidth(e);this.domNode.style.width=t+"px",this.domNode.style.left=this._getLeft(e)+"px",this._onWidth(t)})))}dispose(){this._overlayWidget&&(this.editor.removeOverlayWidget(this._overlayWidget),this._overlayWidget=null),this._viewZone&&this.editor.changeViewZones((e=>{this._viewZone&&e.removeZone(this._viewZone.id),this._viewZone=null})),this._positionMarkerId.clear(),this._disposables.dispose()}create(){this.domNode.classList.add("zone-widget"),this.options.className&&this.domNode.classList.add(this.options.className),this.container=document.createElement("div"),this.container.classList.add("zone-widget-container"),this.domNode.appendChild(this.container),this.options.showArrow&&(this._arrow=new y(this.editor),this._disposables.add(this._arrow)),this._fillContainer(this.container),this._initSash(),this._applyStyles()}style(e){e.frameColor&&(this.options.frameColor=e.frameColor),e.arrowColor&&(this.options.arrowColor=e.arrowColor),this._applyStyles()}_applyStyles(){if(this.container&&this.options.frameColor){const e=this.options.frameColor.toString();this.container.style.borderTopColor=e,this.container.style.borderBottomColor=e}if(this._arrow&&this.options.arrowColor){const e=this.options.arrowColor.toString();this._arrow.color=e}}_getWidth(e){return e.width-e.minimap.minimapWidth-e.verticalScrollbarWidth}_getLeft(e){return e.minimap.minimapWidth>0&&0===e.minimap.minimapLeft?e.minimap.minimapWidth:0}_onViewZoneTop(e){this.domNode.style.top=e+"px"}_onViewZoneHeight(e){if(this.domNode.style.height=`${e}px`,this.container){const t=e-this._decoratingElementsHeight();this.container.style.height=`${t}px`;const i=this.editor.getLayoutInfo();this._doLayout(t,this._getWidth(i))}this._resizeSash?.layout()}get position(){const e=this._positionMarkerId.getRange(0);if(e)return e.getStartPosition()}show(e,t){const i=_.Q.isIRange(e)?_.Q.lift(e):_.Q.fromPositions(e);this._isShowing=!0,this._showImpl(i,t),this._isShowing=!1,this._positionMarkerId.set([{range:i,options:v.kI.EMPTY}])}hide(){this._viewZone&&(this.editor.changeViewZones((e=>{this._viewZone&&e.removeZone(this._viewZone.id)})),this._viewZone=null),this._overlayWidget&&(this.editor.removeOverlayWidget(this._overlayWidget),this._overlayWidget=null),this._arrow?.hide(),this._positionMarkerId.clear()}_decoratingElementsHeight(){const e=this.editor.getOption(67);let t=0;if(this.options.showArrow){t+=2*Math.round(e/3)}if(this.options.showFrame){t+=2*Math.round(e/9)}return t}_showImpl(e,t){const i=e.getStartPosition(),s=this.editor.getLayoutInfo(),n=this._getWidth(s);this.domNode.style.width=`${n}px`,this.domNode.style.left=this._getLeft(s)+"px";const r=document.createElement("div");r.style.overflow="hidden";const o=this.editor.getOption(67);if(!this.options.allowUnlimitedHeight){const e=Math.max(12,this.editor.getLayoutInfo().height/o*.8);t=Math.min(t,e)}let a=0,l=0;if(this._arrow&&this.options.showArrow&&(a=Math.round(o/3),this._arrow.height=a,this._arrow.show(i)),this.options.showFrame&&(l=Math.round(o/9)),this.editor.changeViewZones((e=>{this._viewZone&&e.removeZone(this._viewZone.id),this._overlayWidget&&(this.editor.removeOverlayWidget(this._overlayWidget),this._overlayWidget=null),this.domNode.style.top="-1000px",this._viewZone=new E(r,i.lineNumber,i.column,t,(e=>this._onViewZoneTop(e)),(e=>this._onViewZoneHeight(e)),this.options.showInHiddenAreas,this.options.ordinal),this._viewZone.id=e.addZone(this._viewZone),this._overlayWidget=new S("vs.editor.contrib.zoneWidget"+this._viewZone.id,this.domNode),this.editor.addOverlayWidget(this._overlayWidget)})),this.container&&this.options.showFrame){const e=this.options.frameWidth?this.options.frameWidth:l;this.container.style.borderTopWidth=e+"px",this.container.style.borderBottomWidth=e+"px"}const c=t*o-this._decoratingElementsHeight();this.container&&(this.container.style.top=a+"px",this.container.style.height=c+"px",this.container.style.overflow="hidden"),this._doLayout(c,n),this.options.keepEditorSelection||this.editor.setSelection(e);const h=this.editor.getModel();if(h){const t=h.validateRange(new _.Q(e.startLineNumber,1,e.endLineNumber+1,1));this.revealRange(t,t.startLineNumber===h.getLineCount())}}revealRange(e,t){t?this.editor.revealLineNearTop(e.endLineNumber,0):this.editor.revealRange(e,0)}setCssClass(e,t){this.container&&(t&&this.container.classList.remove(t),this.container.classList.add(e))}_onWidth(e){}_doLayout(e,t){}_relayout(e){this._viewZone&&this._viewZone.heightInLines!==e&&this.editor.changeViewZones((t=>{this._viewZone&&(this._viewZone.heightInLines=e,t.layoutZone(this._viewZone.id))}))}_initSash(){if(this._resizeSash)return;let e;this._resizeSash=this._disposables.add(new p.m(this.domNode,this,{orientation:1})),this.options.isResizeable||(this._resizeSash.state=0),this._disposables.add(this._resizeSash.onDidStart((t=>{this._viewZone&&(e={startY:t.startY,heightInLines:this._viewZone.heightInLines})}))),this._disposables.add(this._resizeSash.onDidEnd((()=>{e=void 0}))),this._disposables.add(this._resizeSash.onDidChange((t=>{if(e){const i=(t.currentY-e.startY)/this.editor.getOption(67),s=i<0?Math.ceil(i):Math.floor(i),n=e.heightInLines+s;n>5&&n<35&&this._relayout(n)}})))}getHorizontalSashLeft(){return 0}getHorizontalSashTop(){return(null===this.domNode.style.height?0:parseInt(this.domNode.style.height))-this._decoratingElementsHeight()/2}getHorizontalSashWidth(){const e=this.editor.getLayoutInfo();return e.width-e.minimap.minimapWidth}}var L=i(78209),R=i(57629),T=i(32848),x=i(14718),k=i(63591),A=i(66261),N=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},I=function(e,t){return function(i,s){t(i,s,e)}};const O=(0,k.u1)("IPeekViewService");var D;(0,x.v)(O,class{constructor(){this._widgets=new Map}addExclusiveWidget(e,t){const i=this._widgets.get(e);i&&(i.listener.dispose(),i.widget.dispose());this._widgets.set(e,{widget:t,listener:t.onDidClose((()=>{const i=this._widgets.get(e);i&&i.widget===t&&(i.listener.dispose(),this._widgets.delete(e))}))})}},1),function(e){e.inPeekEditor=new T.N1("inReferenceSearchEditor",!0,L.kg("inReferenceSearchEditor","Whether the current code editor is embedded inside peek")),e.notInPeekEditor=e.inPeekEditor.toNegated()}(D||(D={}));let M=class{static{this.ID="editor.contrib.referenceController"}constructor(e,t){e instanceof g.t&&D.inPeekEditor.bindTo(t)}dispose(){}};function P(e){const t=e.get(u.T).getFocusedCodeEditor();return t instanceof g.t?t.getParentEditor():t}M=N([I(1,T.fN)],M),(0,d.HW)(M.ID,M,0);const F={headerBackgroundColor:l.Q1.white,primaryHeadingColor:l.Q1.fromHex("#333333"),secondaryHeadingColor:l.Q1.fromHex("#6c6c6cb3")};let U=class extends w{constructor(e,t,i){super(e,t),this.instantiationService=i,this._onDidClose=new c.vl,this.onDidClose=this._onDidClose.event,h.co(this.options,F,!1)}dispose(){this.disposed||(this.disposed=!0,super.dispose(),this._onDidClose.fire(this))}style(e){const t=this.options;e.headerBackgroundColor&&(t.headerBackgroundColor=e.headerBackgroundColor),e.primaryHeadingColor&&(t.primaryHeadingColor=e.primaryHeadingColor),e.secondaryHeadingColor&&(t.secondaryHeadingColor=e.secondaryHeadingColor),super.style(e)}_applyStyles(){super._applyStyles();const e=this.options;this._headElement&&e.headerBackgroundColor&&(this._headElement.style.backgroundColor=e.headerBackgroundColor.toString()),this._primaryHeading&&e.primaryHeadingColor&&(this._primaryHeading.style.color=e.primaryHeadingColor.toString()),this._secondaryHeading&&e.secondaryHeadingColor&&(this._secondaryHeading.style.color=e.secondaryHeadingColor.toString()),this._bodyElement&&e.frameColor&&(this._bodyElement.style.borderColor=e.frameColor.toString())}_fillContainer(e){this.setCssClass("peekview-widget"),this._headElement=s.$(".head"),this._bodyElement=s.$(".body"),this._fillHead(this._headElement),this._fillBody(this._bodyElement),e.appendChild(this._headElement),e.appendChild(this._bodyElement)}_fillHead(e,t){this._titleElement=s.$(".peekview-title"),this.options.supportOnTitleClick&&(this._titleElement.classList.add("clickable"),s.b2(this._titleElement,"click",(e=>this._onTitleClick(e)))),s.BC(this._headElement,this._titleElement),this._fillTitleIcon(this._titleElement),this._primaryHeading=s.$("span.filename"),this._secondaryHeading=s.$("span.dirname"),this._metaHeading=s.$("span.meta"),s.BC(this._titleElement,this._primaryHeading,this._secondaryHeading,this._metaHeading);const i=s.$(".peekview-actions");s.BC(this._headElement,i);const l=this._getActionBarOptions();this._actionbarWidget=new n.E(i,l),this._disposables.add(this._actionbarWidget),t||this._actionbarWidget.push(new r.rc("peekview.close",L.kg("label.close","Close"),a.L.asClassName(o.W.close),!0,(()=>(this.dispose(),Promise.resolve()))),{label:!1,icon:!0})}_fillTitleIcon(e){}_getActionBarOptions(){return{actionViewItemProvider:R.rN.bind(void 0,this.instantiationService),orientation:0}}_onTitleClick(e){}setTitle(e,t){this._primaryHeading&&this._secondaryHeading&&(this._primaryHeading.innerText=e,this._primaryHeading.setAttribute("title",e),t?this._secondaryHeading.innerText=t:s.w_(this._secondaryHeading))}setMetaTitle(e){this._metaHeading&&(e?(this._metaHeading.innerText=e,s.WU(this._metaHeading)):s.jD(this._metaHeading))}_doLayout(e,t){if(!this._isShowing&&e<0)return void this.dispose();const i=Math.ceil(1.2*this.editor.getOption(67)),s=Math.round(e-(i+2));this._doLayoutHead(i,t),this._doLayoutBody(s,t)}_doLayoutHead(e,t){this._headElement&&(this._headElement.style.height=`${e}px`,this._headElement.style.lineHeight=this._headElement.style.height)}_doLayoutBody(e,t){this._bodyElement&&(this._bodyElement.style.height=`${e}px`)}};U=N([I(2,k._Y)],U);const H=(0,A.x1A)("peekViewTitle.background",{dark:"#252526",light:"#F3F3F3",hcDark:l.Q1.black,hcLight:l.Q1.white},L.kg("peekViewTitleBackground","Background color of the peek view title area.")),B=(0,A.x1A)("peekViewTitleLabel.foreground",{dark:l.Q1.white,light:l.Q1.black,hcDark:l.Q1.white,hcLight:A.By2},L.kg("peekViewTitleForeground","Color of the peek view title.")),W=(0,A.x1A)("peekViewTitleDescription.foreground",{dark:"#ccccccb3",light:"#616161",hcDark:"#FFFFFF99",hcLight:"#292929"},L.kg("peekViewTitleInfoForeground","Color of the peek view title info.")),V=(0,A.x1A)("peekView.border",{dark:A.pOz,light:A.pOz,hcDark:A.b1q,hcLight:A.b1q},L.kg("peekViewBorder","Color of the peek view borders and arrow.")),z=(0,A.x1A)("peekViewResult.background",{dark:"#252526",light:"#F3F3F3",hcDark:l.Q1.black,hcLight:l.Q1.white},L.kg("peekViewResultsBackground","Background color of the peek view result list.")),G=((0,A.x1A)("peekViewResult.lineForeground",{dark:"#bbbbbb",light:"#646465",hcDark:l.Q1.white,hcLight:A.By2},L.kg("peekViewResultsMatchForeground","Foreground color for line nodes in the peek view result list.")),(0,A.x1A)("peekViewResult.fileForeground",{dark:l.Q1.white,light:"#1E1E1E",hcDark:l.Q1.white,hcLight:A.By2},L.kg("peekViewResultsFileForeground","Foreground color for file nodes in the peek view result list.")),(0,A.x1A)("peekViewResult.selectionBackground",{dark:"#3399ff33",light:"#3399ff33",hcDark:null,hcLight:null},L.kg("peekViewResultsSelectionBackground","Background color of the selected entry in the peek view result list.")),(0,A.x1A)("peekViewResult.selectionForeground",{dark:l.Q1.white,light:"#6C6C6C",hcDark:l.Q1.white,hcLight:A.By2},L.kg("peekViewResultsSelectionForeground","Foreground color of the selected entry in the peek view result list.")),(0,A.x1A)("peekViewEditor.background",{dark:"#001F33",light:"#F2F8FC",hcDark:l.Q1.black,hcLight:l.Q1.white},L.kg("peekViewEditorBackground","Background color of the peek view editor.")));(0,A.x1A)("peekViewEditorGutter.background",G,L.kg("peekViewEditorGutterBackground","Background color of the gutter in the peek view editor.")),(0,A.x1A)("peekViewEditorStickyScroll.background",G,L.kg("peekViewEditorStickScrollBackground","Background color of sticky scroll in the peek view editor.")),(0,A.x1A)("peekViewResult.matchHighlightBackground",{dark:"#ea5c004d",light:"#ea5c004d",hcDark:null,hcLight:null},L.kg("peekViewResultsMatchHighlight","Match highlight color in the peek view result list.")),(0,A.x1A)("peekViewEditor.matchHighlightBackground",{dark:"#ff8f0099",light:"#f5d802de",hcDark:null,hcLight:null},L.kg("peekViewEditorMatchHighlight","Match highlight color in the peek view editor.")),(0,A.x1A)("peekViewEditor.matchHighlightBorder",{dark:null,light:null,hcDark:A.buw,hcLight:A.buw},L.kg("peekViewEditorMatchHighlightBorder","Match highlight border in the peek view editor."))},85646:(e,t,i)=>{"use strict";var s=i(31450),n=i(87119),r=i(78209),o=i(83844),a=i(1098),l=i(30076),c=i(41127),h=i(31308),d=i(63591),u=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},g=function(e,t){return function(i,s){t(i,s,e)}};class p{constructor(e){this.instantiationService=e}init(...e){}}let m=class extends p{constructor(e,t){super(t),this.init(e)}};var f;m=u([g(1,d._Y)],m),(0,s.HW)(a.X.ID,(f=()=>a.X,(0,l.e)()?function(e,t){return class extends t{constructor(){super(...arguments),this._autorun=void 0}init(...t){this._autorun=(0,h.yC)(((i,s)=>{const n=(0,c.b)(e(),i);s.add(this.instantiationService.createInstance(n,...t))}))}dispose(){this._autorun?.dispose()}}}(f,m):f()),0),(0,o.x1)("editor.placeholder.foreground",n.Ek,(0,r.kg)("placeholderForeground","Foreground color of the placeholder text in the editor."))},1098:(e,t,i)=>{"use strict";i.d(t,{X:()=>c});var s=i(8597),n=i(51241),r=i(5662),o=i(31308),a=i(87958),l=i(38844);class c extends r.jG{static{this.ID="editor.contrib.placeholderText"}constructor(e){var t,i;super(),this._editor=e,this._editorObs=(0,l.Ud)(this._editor),this._placeholderText=this._editorObs.getOption(88),this._state=(0,o.C)({owner:this,equalsFn:n.dB},(e=>{const t=this._placeholderText.read(e);if(t&&this._editorObs.valueIsEmpty.read(e))return{placeholder:t}})),this._shouldViewBeAlive=(t=this,i=e=>void 0!==this._state.read(e)?.placeholder,(0,o.ZX)(t,((e,t)=>!0===t||i(e)))),this._view=(0,a.rm)(((e,t)=>{if(!this._shouldViewBeAlive.read(e))return;const i=(0,s.h)("div.editorPlaceholder");t.add((0,o.fm)((e=>{const t=this._state.read(e),s=void 0!==t?.placeholder;i.root.style.display=s?"block":"none",i.root.innerText=t?.placeholder??""}))),t.add((0,o.fm)((e=>{const t=this._editorObs.layoutInfo.read(e);i.root.style.left=`${t.contentLeft}px`,i.root.style.width=t.contentWidth-t.verticalScrollbarWidth+"px",i.root.style.top=`${this._editor.getTopForLineNumber(0)}px`}))),t.add((0,o.fm)((e=>{i.root.style.fontFamily=this._editorObs.getOption(49).read(e),i.root.style.fontSize=this._editorObs.getOption(52).read(e)+"px",i.root.style.lineHeight=this._editorObs.getOption(67).read(e)+"px"}))),t.add(this._editorObs.createOverlayWidget({allowEditorOverflow:!1,minContentWidthInPx:(0,o.lk)(0),position:(0,o.lk)(null),domNode:i.root}))})),this._view.recomputeInitiallyAndOnChange(this._store)}}},12437:(e,t,i)=>{"use strict";i.d(t,{o:()=>h});var s=i(6921),n=i(5662),r=i(34326),o=i(16223),a=i(87119),l=i(47612),c=i(11007);class h{constructor(e){this.options=e,this.rangeHighlightDecorationId=void 0}provide(e,t,i){const s=new n.Cm;e.canAcceptInBackground=!!this.options?.canAcceptInBackground,e.matchOnLabel=e.matchOnDescription=e.matchOnDetail=e.sortByLabel=!1;const r=s.add(new n.HE);return r.value=this.doProvide(e,t,i),s.add(this.onDidActiveTextEditorControlChange((()=>{r.value=void 0,r.value=this.doProvide(e,t)}))),s}doProvide(e,t,i){const o=new n.Cm,a=this.activeTextEditorControl;if(a&&this.canProvideWithTextEditor(a)){const l={editor:a},c=(0,r.jA)(a);if(c){let e=a.saveViewState()??void 0;o.add(c.onDidChangeCursorPosition((()=>{e=a.saveViewState()??void 0}))),l.restoreViewState=()=>{e&&a===this.activeTextEditorControl&&a.restoreViewState(e)},o.add((0,s.P)(t.onCancellationRequested)((()=>l.restoreViewState?.())))}o.add((0,n.s)((()=>this.clearDecorations(a)))),o.add(this.provideWithTextEditor(l,e,t,i))}else o.add(this.provideWithoutTextEditor(e,t));return o}canProvideWithTextEditor(e){return!0}gotoLocation({editor:e},t){e.setSelection(t.range,"code.jump"),e.revealRangeInCenter(t.range,0),t.preserveFocus||e.focus();const i=e.getModel();i&&"getLineContent"in i&&(0,c.h5)(`${i.getLineContent(t.range.startLineNumber)}`)}getModel(e){return(0,r.Np)(e)?e.getModel()?.modified:e.getModel()}addDecorations(e,t){e.changeDecorations((e=>{const i=[];this.rangeHighlightDecorationId&&(i.push(this.rangeHighlightDecorationId.overviewRulerDecorationId),i.push(this.rangeHighlightDecorationId.rangeHighlightId),this.rangeHighlightDecorationId=void 0);const s=[{range:t,options:{description:"quick-access-range-highlight",className:"rangeHighlight",isWholeLine:!0}},{range:t,options:{description:"quick-access-range-highlight-overview",overviewRuler:{color:(0,l.Yf)(a.vp),position:o.A5.Full}}}],[n,r]=e.deltaDecorations(i,s);this.rangeHighlightDecorationId={rangeHighlightId:n,overviewRulerDecorationId:r}}))}clearDecorations(e){const t=this.rangeHighlightDecorationId;t&&(e.changeDecorations((e=>{e.deltaDecorations([t.overviewRulerDecorationId,t.rangeHighlightId],[])})),this.rangeHighlightDecorationId=void 0)}}},59731:(e,t,i)=>{"use strict";var s=i(16980),n=i(5662),r=i(31450),o=i(99645),a=i(78209);class l extends n.jG{static{this.ID="editor.contrib.readOnlyMessageController"}constructor(e){super(),this.editor=e,this._register(this.editor.onDidAttemptReadOnlyEdit((()=>this._onDidAttemptReadOnlyEdit())))}_onDidAttemptReadOnlyEdit(){const e=o.k.get(this.editor);if(e&&this.editor.hasModel()){let t=this.editor.getOptions().get(93);t||(t=this.editor.isSimpleWidget?new s.Bc(a.kg("editor.simple.readonly","Cannot edit in read-only input")):new s.Bc(a.kg("editor.readonly","Cannot edit in read-only editor"))),e.showMessage(t,this.editor.getPosition())}}}(0,r.HW)(l.ID,l,2)},50071:(e,t,i)=>{"use strict";var s=i(11007),n=i(90766),r=i(18447),o=i(64383),a=i(16980),l=i(5662),c=i(631),h=i(79400),d=i(31450),u=i(80537),g=i(80301),p=i(83069),m=i(36677),f=i(60002),_=i(62083),v=i(56942),C=i(90360),b=i(50868),E=i(99645),S=i(78209),y=i(27195),w=i(1646),L=i(32848),R=i(63591),T=i(18801),x=i(58591),k=i(73823),A=i(46359),N=i(90651),I=i(8597),O=i(72962),D=i(48196),M=i(42904),P=i(20370),F=i(93090),U=i(25890),H=i(10350),B=i(41234),W=i(78381),V=i(73157),z=i(98031),G=i(19070),j=i(66261),K=i(47612),Y=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},q=function(e,t){return function(i,s){t(i,s,e)}};const $=new L.N1("renameInputVisible",!1,S.kg("renameInputVisible","Whether the rename input widget is visible"));new L.N1("renameInputFocused",!1,S.kg("renameInputFocused","Whether the rename input widget is focused"));let Q=class{constructor(e,t,i,s,n,r){this._editor=e,this._acceptKeybindings=t,this._themeService=i,this._keybindingService=s,this._logService=r,this.allowEditorOverflow=!0,this._disposables=new l.Cm,this._visibleContextKey=$.bindTo(n),this._isEditingRenameCandidate=!1,this._nRenameSuggestionsInvocations=0,this._hadAutomaticRenameSuggestionsInvocation=!1,this._candidates=new Set,this._beforeFirstInputFieldEditSW=new W.W,this._inputWithButton=new Z,this._disposables.add(this._inputWithButton),this._editor.addContentWidget(this),this._disposables.add(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(50)&&this._updateFont()}))),this._disposables.add(i.onDidColorThemeChange(this._updateStyles,this))}dispose(){this._disposables.dispose(),this._editor.removeContentWidget(this)}getId(){return"__renameInputWidget"}getDomNode(){return this._domNode||(this._domNode=document.createElement("div"),this._domNode.className="monaco-editor rename-box",this._domNode.appendChild(this._inputWithButton.domNode),this._renameCandidateListView=this._disposables.add(new X(this._domNode,{fontInfo:this._editor.getOption(50),onFocusChange:e=>{this._inputWithButton.input.value=e,this._isEditingRenameCandidate=!1},onSelectionChange:()=>{this._isEditingRenameCandidate=!1,this.acceptInput(!1)}})),this._disposables.add(this._inputWithButton.onDidInputChange((()=>{void 0!==this._renameCandidateListView?.focusedCandidate&&(this._isEditingRenameCandidate=!0),this._timeBeforeFirstInputFieldEdit??=this._beforeFirstInputFieldEditSW.elapsed(),!1===this._renameCandidateProvidersCts?.token.isCancellationRequested&&this._renameCandidateProvidersCts.cancel(),this._renameCandidateListView?.clearFocus()}))),this._label=document.createElement("div"),this._label.className="rename-label",this._domNode.appendChild(this._label),this._updateFont(),this._updateStyles(this._themeService.getColorTheme())),this._domNode}_updateStyles(e){if(!this._domNode)return;const t=e.getColor(j.f9l),i=e.getColor(j.DSL);this._domNode.style.backgroundColor=String(e.getColor(j.CgL)??""),this._domNode.style.boxShadow=t?` 0 0 8px 2px ${t}`:"",this._domNode.style.border=i?`1px solid ${i}`:"",this._domNode.style.color=String(e.getColor(j.cws)??"");const s=e.getColor(j.Zgs);this._inputWithButton.domNode.style.backgroundColor=String(e.getColor(j.L4c)??""),this._inputWithButton.input.style.backgroundColor=String(e.getColor(j.L4c)??""),this._inputWithButton.domNode.style.borderWidth=s?"1px":"0px",this._inputWithButton.domNode.style.borderStyle=s?"solid":"none",this._inputWithButton.domNode.style.borderColor=s?.toString()??"none"}_updateFont(){if(void 0===this._domNode)return;(0,c.j)(void 0!==this._label,"RenameWidget#_updateFont: _label must not be undefined given _domNode is defined"),this._editor.applyFontInfo(this._inputWithButton.input);const e=this._editor.getOption(50);this._label.style.fontSize=`${this._computeLabelFontSize(e.fontSize)}px`}_computeLabelFontSize(e){return.8*e}getPosition(){if(!this._visible)return null;if(!this._editor.hasModel()||!this._editor.getDomNode())return null;const e=I.tG(this.getDomNode().ownerDocument.body),t=I.BK(this._editor.getDomNode()),i=this._getTopForPosition();this._nPxAvailableAbove=i+t.top,this._nPxAvailableBelow=e.height-this._nPxAvailableAbove;const s=this._editor.getOption(67),{totalHeight:n}=J.getLayoutInfo({lineHeight:s}),r=this._nPxAvailableBelow>6*n?[2,1]:[1,2];return{position:this._position,preference:r}}beforeRender(){const[e,t]=this._acceptKeybindings;return this._label.innerText=S.kg({key:"label",comment:['placeholders are keybindings, e.g "F2 to Rename, Shift+F2 to Preview"']},"{0} to Rename, {1} to Preview",this._keybindingService.lookupKeybinding(e)?.getLabel(),this._keybindingService.lookupKeybinding(t)?.getLabel()),this._domNode.style.minWidth="200px",null}afterRender(e){if(null===e)return void this.cancelInput(!0,"afterRender (because position is null)");if(!this._editor.hasModel()||!this._editor.getDomNode())return;(0,c.j)(this._renameCandidateListView),(0,c.j)(void 0!==this._nPxAvailableAbove),(0,c.j)(void 0!==this._nPxAvailableBelow);const t=I.OK(this._inputWithButton.domNode),i=I.OK(this._label);let s;s=2===e?this._nPxAvailableBelow:this._nPxAvailableAbove,this._renameCandidateListView.layout({height:s-i-t,width:I.Tr(this._inputWithButton.domNode)})}acceptInput(e){this._trace("invoking acceptInput"),this._currentAcceptInput?.(e)}cancelInput(e,t){this._currentCancelInput?.(e)}focusNextRenameSuggestion(){this._renameCandidateListView?.focusNext()||(this._inputWithButton.input.value=this._currentName)}focusPreviousRenameSuggestion(){this._renameCandidateListView?.focusPrevious()||(this._inputWithButton.input.value=this._currentName)}getInput(e,t,i,s,r){const{start:o,end:a}=this._getSelection(e,t);this._renameCts=r;const h=new l.Cm;this._nRenameSuggestionsInvocations=0,this._hadAutomaticRenameSuggestionsInvocation=!1,void 0===s?this._inputWithButton.button.style.display="none":(this._inputWithButton.button.style.display="flex",this._requestRenameCandidatesOnce=s,this._requestRenameCandidates(t,!1),h.add(I.ko(this._inputWithButton.button,"click",(()=>this._requestRenameCandidates(t,!0)))),h.add(I.ko(this._inputWithButton.button,I.Bx.KEY_DOWN,(e=>{const i=new O.Z(e);(i.equals(3)||i.equals(10))&&(i.stopPropagation(),i.preventDefault(),this._requestRenameCandidates(t,!0))})))),this._isEditingRenameCandidate=!1,this._domNode.classList.toggle("preview",i),this._position=new p.y(e.startLineNumber,e.startColumn),this._currentName=t,this._inputWithButton.input.value=t,this._inputWithButton.input.setAttribute("selectionStart",o.toString()),this._inputWithButton.input.setAttribute("selectionEnd",a.toString()),this._inputWithButton.input.size=Math.max(1.1*(e.endColumn-e.startColumn),20),this._beforeFirstInputFieldEditSW.reset(),h.add((0,l.s)((()=>{this._renameCts=void 0,r.dispose(!0)}))),h.add((0,l.s)((()=>{void 0!==this._renameCandidateProvidersCts&&(this._renameCandidateProvidersCts.dispose(!0),this._renameCandidateProvidersCts=void 0)}))),h.add((0,l.s)((()=>this._candidates.clear())));const d=new n.Zv;return d.p.finally((()=>{h.dispose(),this._hide()})),this._currentCancelInput=e=>(this._trace("invoking _currentCancelInput"),this._currentAcceptInput=void 0,this._currentCancelInput=void 0,this._renameCandidateListView?.clearCandidates(),d.complete(e),!0),this._currentAcceptInput=e=>{this._trace("invoking _currentAcceptInput"),(0,c.j)(void 0!==this._renameCandidateListView);const s=this._renameCandidateListView.nCandidates;let n,r;const o=this._renameCandidateListView.focusedCandidate;void 0!==o?(this._trace("using new name from renameSuggestion"),n=o,r={k:"renameSuggestion"}):(this._trace("using new name from inputField"),n=this._inputWithButton.input.value,r=this._isEditingRenameCandidate?{k:"userEditedRenameSuggestion"}:{k:"inputField"}),n!==t&&0!==n.trim().length?(this._currentAcceptInput=void 0,this._currentCancelInput=void 0,this._renameCandidateListView.clearCandidates(),d.complete({newName:n,wantsPreview:i&&e,stats:{source:r,nRenameSuggestions:s,timeBeforeFirstInputFieldEdit:this._timeBeforeFirstInputFieldEdit,nRenameSuggestionsInvocations:this._nRenameSuggestionsInvocations,hadAutomaticRenameSuggestionsInvocation:this._hadAutomaticRenameSuggestionsInvocation}})):this.cancelInput(!0,"_currentAcceptInput (because newName === value || newName.trim().length === 0)")},h.add(r.token.onCancellationRequested((()=>this.cancelInput(!0,"cts.token.onCancellationRequested")))),h.add(this._editor.onDidBlurEditorWidget((()=>this.cancelInput(!this._domNode?.ownerDocument.hasFocus(),"editor.onDidBlurEditorWidget")))),this._show(),d.p}_requestRenameCandidates(e,t){if(void 0!==this._requestRenameCandidatesOnce&&(void 0!==this._renameCandidateProvidersCts&&this._renameCandidateProvidersCts.dispose(!0),(0,c.j)(this._renameCts),"stop"!==this._inputWithButton.buttonState)){this._renameCandidateProvidersCts=new r.Qi;const i=t?_.YT.Invoke:_.YT.Automatic,s=this._requestRenameCandidatesOnce(i,this._renameCandidateProvidersCts.token);if(0===s.length)return void this._inputWithButton.setSparkleButton();t||(this._hadAutomaticRenameSuggestionsInvocation=!0),this._nRenameSuggestionsInvocations+=1,this._inputWithButton.setStopButton(),this._updateRenameCandidates(s,e,this._renameCts.token)}}_getSelection(e,t){(0,c.j)(this._editor.hasModel());const i=this._editor.getSelection();let s=0,n=t.length;return m.Q.isEmpty(i)||m.Q.spansMultipleLines(i)||!m.Q.containsRange(e,i)||(s=Math.max(0,i.startColumn-e.startColumn),n=Math.min(e.endColumn,i.endColumn)-e.startColumn),{start:s,end:n}}_show(){this._trace("invoking _show"),this._editor.revealLineInCenterIfOutsideViewport(this._position.lineNumber,0),this._visible=!0,this._visibleContextKey.set(!0),this._editor.layoutContentWidget(this),setTimeout((()=>{this._inputWithButton.input.focus(),this._inputWithButton.input.setSelectionRange(parseInt(this._inputWithButton.input.getAttribute("selectionStart")),parseInt(this._inputWithButton.input.getAttribute("selectionEnd")))}),100)}async _updateRenameCandidates(e,t,i){const s=(...e)=>this._trace("_updateRenameCandidates",...e);s("start");const r=await(0,n.PK)(Promise.allSettled(e),i);if(this._inputWithButton.setSparkleButton(),void 0===r)return void s("returning early - received updateRenameCandidates results - undefined");const o=r.flatMap((e=>"fulfilled"===e.status&&(0,c.O9)(e.value)?e.value:[]));s(`received updateRenameCandidates results - total (unfiltered) ${o.length} candidates.`);const a=U.dM(o,(e=>e.newSymbolName));s(`distinct candidates - ${a.length} candidates.`);const l=a.filter((({newSymbolName:e})=>e.trim().length>0&&e!==this._inputWithButton.input.value&&e!==t&&!this._candidates.has(e)));s(`valid distinct candidates - ${o.length} candidates.`),l.forEach((e=>this._candidates.add(e.newSymbolName))),l.length<1?s("returning early - no valid distinct candidates"):(s("setting candidates"),this._renameCandidateListView.setCandidates(l),s("asking editor to re-layout"),this._editor.layoutContentWidget(this))}_hide(){this._trace("invoked _hide"),this._visible=!1,this._visibleContextKey.reset(),this._editor.layoutContentWidget(this)}_getTopForPosition(){const e=this._editor.getVisibleRanges();let t;return e.length>0?t=e[0].startLineNumber:(this._logService.warn("RenameWidget#_getTopForPosition: this should not happen - visibleRanges is empty"),t=Math.max(1,this._position.lineNumber-5)),this._editor.getTopForLineNumber(this._position.lineNumber)-this._editor.getTopForLineNumber(t)}_trace(...e){this._logService.trace("RenameWidget",...e)}};Q=Y([q(2,K.Gy),q(3,z.b),q(4,L.fN),q(5,T.rr)],Q);class X{constructor(e,t){this._disposables=new l.Cm,this._availableHeight=0,this._minimumWidth=0,this._lineHeight=t.fontInfo.lineHeight,this._typicalHalfwidthCharacterWidth=t.fontInfo.typicalHalfwidthCharacterWidth,this._listContainer=document.createElement("div"),this._listContainer.className="rename-box rename-candidate-list-container",e.appendChild(this._listContainer),this._listWidget=X._createListWidget(this._listContainer,this._candidateViewHeight,t.fontInfo),this._listWidget.onDidChangeFocus((e=>{1===e.elements.length&&t.onFocusChange(e.elements[0].newSymbolName)}),this._disposables),this._listWidget.onDidChangeSelection((e=>{1===e.elements.length&&t.onSelectionChange()}),this._disposables),this._disposables.add(this._listWidget.onDidBlur((e=>{this._listWidget.setFocus([])}))),this._listWidget.style((0,G.t8)({listInactiveFocusForeground:j.nH,listInactiveFocusBackground:j.AlL}))}dispose(){this._listWidget.dispose(),this._disposables.dispose()}layout({height:e,width:t}){this._availableHeight=e,this._minimumWidth=t}setCandidates(e){this._listWidget.splice(0,0,e);const t=this._pickListHeight(this._listWidget.length),i=this._pickListWidth(e);this._listWidget.layout(t,i),this._listContainer.style.height=`${t}px`,this._listContainer.style.width=`${i}px`,s.h5(S.kg("renameSuggestionsReceivedAria","Received {0} rename suggestions",e.length))}clearCandidates(){this._listContainer.style.height="0px",this._listContainer.style.width="0px",this._listWidget.splice(0,this._listWidget.length,[])}get nCandidates(){return this._listWidget.length}get focusedCandidate(){if(0===this._listWidget.length)return;const e=this._listWidget.getSelectedElements()[0];if(void 0!==e)return e.newSymbolName;const t=this._listWidget.getFocusedElements()[0];return void 0!==t?t.newSymbolName:void 0}focusNext(){if(0===this._listWidget.length)return!1;const e=this._listWidget.getFocus();if(0===e.length)return this._listWidget.focusFirst(),this._listWidget.reveal(0),!0;if(e[0]===this._listWidget.length-1)return this._listWidget.setFocus([]),this._listWidget.reveal(0),!1;{this._listWidget.focusNext();const e=this._listWidget.getFocus()[0];return this._listWidget.reveal(e),!0}}focusPrevious(){if(0===this._listWidget.length)return!1;const e=this._listWidget.getFocus();if(0===e.length){this._listWidget.focusLast();const e=this._listWidget.getFocus()[0];return this._listWidget.reveal(e),!0}if(0===e[0])return this._listWidget.setFocus([]),!1;{this._listWidget.focusPrevious();const e=this._listWidget.getFocus()[0];return this._listWidget.reveal(e),!0}}clearFocus(){this._listWidget.setFocus([])}get _candidateViewHeight(){const{totalHeight:e}=J.getLayoutInfo({lineHeight:this._lineHeight});return e}_pickListHeight(e){const t=this._candidateViewHeight*e;return Math.min(t,this._availableHeight,7*this._candidateViewHeight)}_pickListWidth(e){const t=Math.ceil(Math.max(...e.map((e=>e.newSymbolName.length)))*this._typicalHalfwidthCharacterWidth);return Math.max(this._minimumWidth,25+t+10)}static _createListWidget(e,t,i){const s=new class{getTemplateId(e){return"candidate"}getHeight(e){return t}},n=new class{constructor(){this.templateId="candidate"}renderTemplate(e){return new J(e,i)}renderElement(e,t,i){i.populate(e)}disposeTemplate(e){e.dispose()}};return new F.B8("NewSymbolNameCandidates",e,s,[n],{keyboardSupport:!1,mouseSupport:!0,multipleSelectionSupport:!1})}}class Z{constructor(){this._onDidInputChange=new B.vl,this.onDidInputChange=this._onDidInputChange.event,this._disposables=new l.Cm}get domNode(){return this._domNode||(this._domNode=document.createElement("div"),this._domNode.className="rename-input-with-button",this._domNode.style.display="flex",this._domNode.style.flexDirection="row",this._domNode.style.alignItems="center",this._inputNode=document.createElement("input"),this._inputNode.className="rename-input",this._inputNode.type="text",this._inputNode.style.border="none",this._inputNode.setAttribute("aria-label",S.kg("renameAriaLabel","Rename input. Type new name and press Enter to commit.")),this._domNode.appendChild(this._inputNode),this._buttonNode=document.createElement("div"),this._buttonNode.className="rename-suggestions-button",this._buttonNode.setAttribute("tabindex","0"),this._buttonGenHoverText=S.kg("generateRenameSuggestionsButton","Generate new name suggestions"),this._buttonCancelHoverText=S.kg("cancelRenameSuggestionsButton","Cancel"),this._buttonHover=(0,D.i)().setupManagedHover((0,M.nZ)("element"),this._buttonNode,this._buttonGenHoverText),this._disposables.add(this._buttonHover),this._domNode.appendChild(this._buttonNode),this._disposables.add(I.ko(this.input,I.Bx.INPUT,(()=>this._onDidInputChange.fire()))),this._disposables.add(I.ko(this.input,I.Bx.KEY_DOWN,(e=>{const t=new O.Z(e);15!==t.keyCode&&17!==t.keyCode||this._onDidInputChange.fire()}))),this._disposables.add(I.ko(this.input,I.Bx.CLICK,(()=>this._onDidInputChange.fire()))),this._disposables.add(I.ko(this.input,I.Bx.FOCUS,(()=>{this.domNode.style.outlineWidth="1px",this.domNode.style.outlineStyle="solid",this.domNode.style.outlineOffset="-1px",this.domNode.style.outlineColor="var(--vscode-focusBorder)"}))),this._disposables.add(I.ko(this.input,I.Bx.BLUR,(()=>{this.domNode.style.outline="none"})))),this._domNode}get input(){return(0,c.j)(this._inputNode),this._inputNode}get button(){return(0,c.j)(this._buttonNode),this._buttonNode}get buttonState(){return this._buttonState}setSparkleButton(){this._buttonState="sparkle",this._sparkleIcon??=(0,P.s)(H.W.sparkle),I.w_(this.button),this.button.appendChild(this._sparkleIcon),this.button.setAttribute("aria-label","Generating new name suggestions"),this._buttonHover?.update(this._buttonGenHoverText),this.input.focus()}setStopButton(){this._buttonState="stop",this._stopIcon??=(0,P.s)(H.W.primitiveSquare),I.w_(this.button),this.button.appendChild(this._stopIcon),this.button.setAttribute("aria-label","Cancel generating new name suggestions"),this._buttonHover?.update(this._buttonCancelHoverText),this.input.focus()}dispose(){this._disposables.dispose()}}class J{static{this._PADDING=2}constructor(e,t){this._domNode=document.createElement("div"),this._domNode.className="rename-box rename-candidate",this._domNode.style.display="flex",this._domNode.style.columnGap="5px",this._domNode.style.alignItems="center",this._domNode.style.height=`${t.lineHeight}px`,this._domNode.style.padding=`${J._PADDING}px`;const i=document.createElement("div");i.style.display="flex",i.style.alignItems="center",i.style.width=i.style.height=.8*t.lineHeight+"px",this._domNode.appendChild(i),this._icon=(0,P.s)(H.W.sparkle),this._icon.style.display="none",i.appendChild(this._icon),this._label=document.createElement("div"),V.M(this._label,t),this._domNode.appendChild(this._label),e.appendChild(this._domNode)}populate(e){this._updateIcon(e),this._updateLabel(e)}_updateIcon(e){const t=!!e.tags?.includes(_.OV.AIGenerated);this._icon.style.display=t?"inherit":"none"}_updateLabel(e){this._label.innerText=e.newSymbolName}static getLayoutInfo({lineHeight:e}){return{totalHeight:e+2*J._PADDING}}dispose(){}}var ee,te=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ie=function(e,t){return function(i,s){t(i,s,e)}};class se{constructor(e,t,i){this.model=e,this.position=t,this._providerRenameIdx=0,this._providers=i.ordered(e)}hasProvider(){return this._providers.length>0}async resolveRenameLocation(e){const t=[];for(this._providerRenameIdx=0;this._providerRenameIdx0?t.join("\n"):void 0}:{range:m.Q.fromPositions(this.position),text:"",rejectReason:t.length>0?t.join("\n"):void 0}}async provideRenameEdits(e,t){return this._provideRenameEdits(e,this._providerRenameIdx,[],t)}async _provideRenameEdits(e,t,i,s){const n=this._providers[t];if(!n)return{edits:[],rejectReason:i.join("\n")};const r=await n.provideRenameEdits(this.model,this.position,e,s);return r?r.rejectReason?this._provideRenameEdits(e,t+1,i.concat(r.rejectReason),s):r:this._provideRenameEdits(e,t+1,i.concat(S.kg("no result","No result.")),s)}}let ne=class{static{ee=this}static{this.ID="editor.contrib.renameController"}static get(e){return e.getContribution(ee.ID)}constructor(e,t,i,s,n,o,a,c,h){this.editor=e,this._instaService=t,this._notificationService=i,this._bulkEditService=s,this._progressService=n,this._logService=o,this._configService=a,this._languageFeaturesService=c,this._telemetryService=h,this._disposableStore=new l.Cm,this._cts=new r.Qi,this._renameWidget=this._disposableStore.add(this._instaService.createInstance(Q,this.editor,["acceptRenameInput","acceptRenameInputWithPreview"]))}dispose(){this._disposableStore.dispose(),this._cts.dispose(!0)}async run(){const e=this._logService.trace.bind(this._logService,"[rename]");if(this._cts.dispose(!0),this._cts=new r.Qi,!this.editor.hasModel())return void e("editor has no model");const t=this.editor.getPosition(),i=new se(this.editor.getModel(),t,this._languageFeaturesService.renameProvider);if(!i.hasProvider())return void e("skeleton has no provider");const l=new b.gI(this.editor,5,void 0,this._cts.token);let c;try{e("resolving rename location");const t=i.resolveRenameLocation(l.token);this._progressService.showWhile(t,250),c=await t,e("resolved rename location")}catch(C){return void(C instanceof o.AL?e("resolve rename location cancelled",JSON.stringify(C,null,"\t")):(e("resolve rename location failed",C instanceof Error?C:JSON.stringify(C,null,"\t")),("string"===typeof C||(0,a.VS)(C))&&E.k.get(this.editor)?.showMessage(C||S.kg("resolveRenameLocationFailed","An unknown error occurred while resolving rename location"),t)))}finally{l.dispose()}if(!c)return void e("returning early - no loc");if(c.rejectReason)return e(`returning early - rejected with reason: ${c.rejectReason}`,c.rejectReason),void E.k.get(this.editor)?.showMessage(c.rejectReason,t);if(l.token.isCancellationRequested)return void e("returning early - cts1 cancelled");const h=new b.gI(this.editor,5,c.range,this._cts.token),d=this.editor.getModel(),u=this._languageFeaturesService.newSymbolNamesProvider.all(d),g=await Promise.all(u.map((async e=>[e,await e.supportsAutomaticNewSymbolNamesTriggerKind??!1])));e("creating rename input field and awaiting its result");const p=this._bulkEditService.hasPreviewHandler()&&this._configService.getValue(this.editor.getModel().uri,"editor.rename.enablePreview"),f=await this._renameWidget.getInput(c.range,c.text,p,u.length>0?(e,t)=>{let i=g.slice();return e===_.YT.Automatic&&(i=i.filter((([e,t])=>t))),i.map((([i])=>i.provideNewSymbolNames(d,c.range,e,t)))}:void 0,h);if(e("received response from rename input field"),u.length>0&&this._reportTelemetry(u.length,d.getLanguageId(),f),"boolean"===typeof f)return e(`returning early - rename input field response - ${f}`),f&&this.editor.focus(),void h.dispose();this.editor.focus(),e("requesting rename edits");const v=(0,n.PK)(i.provideRenameEdits(f.newName,h.token),h.token).then((async t=>{if(t)if(this.editor.hasModel()){if(t.rejectReason)return e(`returning early - rejected with reason: ${t.rejectReason}`),void this._notificationService.info(t.rejectReason);this.editor.setSelection(m.Q.fromPositions(this.editor.getSelection().getPosition())),e("applying edits"),this._bulkEditService.apply(t,{editor:this.editor,showPreview:f.wantsPreview,label:S.kg("label","Renaming '{0}' to '{1}'",c?.text,f.newName),code:"undoredo.rename",quotableLabel:S.kg("quotableLabel","Renaming {0} to {1}",c?.text,f.newName),respectAutoSaveConfig:!0}).then((t=>{e("edits applied"),t.ariaSummary&&(0,s.xE)(S.kg("aria","Successfully renamed '{0}' to '{1}'. Summary: {2}",c.text,f.newName,t.ariaSummary))})).catch((t=>{e(`error when applying edits ${JSON.stringify(t,null,"\t")}`),this._notificationService.error(S.kg("rename.failedApply","Rename failed to apply edits")),this._logService.error(t)}))}else e("returning early - no model after rename edits are provided");else e("returning early - no rename edits result")}),(t=>{e("error when providing rename edits",JSON.stringify(t,null,"\t")),this._notificationService.error(S.kg("rename.failed","Rename failed to compute edits")),this._logService.error(t)})).finally((()=>{h.dispose()}));return e("returning rename operation"),this._progressService.showWhile(v,250),v}acceptRenameInput(e){this._renameWidget.acceptInput(e)}cancelRenameInput(){this._renameWidget.cancelInput(!0,"cancelRenameInput command")}focusNextRenameSuggestion(){this._renameWidget.focusNextRenameSuggestion()}focusPreviousRenameSuggestion(){this._renameWidget.focusPreviousRenameSuggestion()}_reportTelemetry(e,t,i){const s="boolean"===typeof i?{kind:"cancelled",languageId:t,nRenameSuggestionProviders:e}:{kind:"accepted",languageId:t,nRenameSuggestionProviders:e,source:i.stats.source.k,nRenameSuggestions:i.stats.nRenameSuggestions,timeBeforeFirstInputFieldEdit:i.stats.timeBeforeFirstInputFieldEdit,wantsPreview:i.wantsPreview,nRenameSuggestionsInvocations:i.stats.nRenameSuggestionsInvocations,hadAutomaticRenameSuggestionsInvocation:i.stats.hadAutomaticRenameSuggestionsInvocation};this._telemetryService.publicLog2("renameInvokedEvent",s)}};ne=ee=te([ie(1,R._Y),ie(2,x.Ot),ie(3,u.nu),ie(4,k.N8),ie(5,T.rr),ie(6,C.ITextResourceConfigurationService),ie(7,v.ILanguageFeaturesService),ie(8,N.k)],ne);class re extends d.ks{constructor(){super({id:"editor.action.rename",label:S.kg("rename.label","Rename Symbol"),alias:"Rename Symbol",precondition:L.M$.and(f.R.writable,f.R.hasRenameProvider),kbOpts:{kbExpr:f.R.editorTextFocus,primary:60,weight:100},contextMenuOpts:{group:"1_modification",order:1.1}})}runCommand(e,t){const i=e.get(g.T),[s,n]=Array.isArray(t)&&t||[void 0,void 0];return h.r.isUri(s)&&p.y.isIPosition(n)?i.openCodeEditor({resource:s},i.getActiveCodeEditor()).then((e=>{e&&(e.setPosition(n),e.invokeWithinContext((t=>(this.reportTelemetry(t,e),this.run(t,e)))))}),o.dz):super.runCommand(e,t)}run(e,t){const i=e.get(T.rr),s=ne.get(t);return s?(i.trace("[RenameAction] got controller, running..."),s.run()):(i.trace("[RenameAction] returning early - controller missing"),Promise.resolve())}}(0,d.HW)(ne.ID,ne,4),(0,d.Fl)(re);const oe=d.DX.bindToContribution(ne.get);(0,d.E_)(new oe({id:"acceptRenameInput",precondition:$,handler:e=>e.acceptRenameInput(!1),kbOpts:{weight:199,kbExpr:L.M$.and(f.R.focus,L.M$.not("isComposing")),primary:3}})),(0,d.E_)(new oe({id:"acceptRenameInputWithPreview",precondition:L.M$.and($,L.M$.has("config.editor.rename.enablePreview")),handler:e=>e.acceptRenameInput(!0),kbOpts:{weight:199,kbExpr:L.M$.and(f.R.focus,L.M$.not("isComposing")),primary:2051}})),(0,d.E_)(new oe({id:"cancelRenameInput",precondition:$,handler:e=>e.cancelRenameInput(),kbOpts:{weight:199,kbExpr:f.R.focus,primary:9,secondary:[1033]}})),(0,y.ug)(class extends y.L{constructor(){super({id:"focusNextRenameSuggestion",title:{...S.aS("focusNextRenameSuggestion","Focus Next Rename Suggestion")},precondition:$,keybinding:[{primary:18,weight:199}]})}run(e){const t=e.get(g.T).getFocusedCodeEditor();if(!t)return;const i=ne.get(t);i&&i.focusNextRenameSuggestion()}}),(0,y.ug)(class extends y.L{constructor(){super({id:"focusPreviousRenameSuggestion",title:{...S.aS("focusPreviousRenameSuggestion","Focus Previous Rename Suggestion")},precondition:$,keybinding:[{primary:16,weight:199}]})}run(e){const t=e.get(g.T).getFocusedCodeEditor();if(!t)return;const i=ne.get(t);i&&i.focusPreviousRenameSuggestion()}}),(0,d.ke)("_executeDocumentRenameProvider",(function(e,t,i,...s){const[n]=s;(0,c.j)("string"===typeof n);const{renameProvider:o}=e.get(v.ILanguageFeaturesService);return async function(e,t,i,s){const n=new se(t,i,e),o=await n.resolveRenameLocation(r.XO.None);return o?.rejectReason?{edits:[],rejectReason:o.rejectReason}:n.provideRenameEdits(s,r.XO.None)}(o,t,i,n)})),(0,d.ke)("_executePrepareRename",(async function(e,t,i){const{renameProvider:s}=e.get(v.ILanguageFeaturesService),n=new se(t,i,s),o=await n.resolveRenameLocation(r.XO.None);if(o?.rejectReason)throw new Error(o.rejectReason);return o})),A.O.as(w.Fd.Configuration).registerConfiguration({id:"editor",properties:{"editor.rename.enablePreview":{scope:5,description:S.kg("enablePreview","Enable/disable the ability to preview changes before renaming"),default:!0,type:"boolean"}}})},18278:(e,t,i)=>{"use strict";var s=i(90766),n=i(5662),r=i(31450),o=i(17469),a=i(87289),l=i(10920),c=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},h=function(e,t){return function(i,s){t(i,s,e)}};let d=class extends n.jG{static{this.ID="editor.sectionHeaderDetector"}constructor(e,t,i){super(),this.editor=e,this.languageConfigurationService=t,this.editorWorkerService=i,this.decorations=this.editor.createDecorationsCollection(),this.options=this.createOptions(e.getOption(73)),this.computePromise=null,this.currentOccurrences={},this._register(e.onDidChangeModel((t=>{this.currentOccurrences={},this.options=this.createOptions(e.getOption(73)),this.stop(),this.computeSectionHeaders.schedule(0)}))),this._register(e.onDidChangeModelLanguage((t=>{this.currentOccurrences={},this.options=this.createOptions(e.getOption(73)),this.stop(),this.computeSectionHeaders.schedule(0)}))),this._register(t.onDidChange((t=>{const i=this.editor.getModel()?.getLanguageId();i&&t.affects(i)&&(this.currentOccurrences={},this.options=this.createOptions(e.getOption(73)),this.stop(),this.computeSectionHeaders.schedule(0))}))),this._register(e.onDidChangeConfiguration((t=>{this.options&&!t.hasChanged(73)||(this.options=this.createOptions(e.getOption(73)),this.updateDecorations([]),this.stop(),this.computeSectionHeaders.schedule(0))}))),this._register(this.editor.onDidChangeModelContent((e=>{this.computeSectionHeaders.schedule()}))),this._register(e.onDidChangeModelTokens((e=>{this.computeSectionHeaders.isScheduled()||this.computeSectionHeaders.schedule(1e3)}))),this.computeSectionHeaders=this._register(new s.uC((()=>{this.findSectionHeaders()}),250)),this.computeSectionHeaders.schedule(0)}createOptions(e){if(!e||!this.editor.hasModel())return;const t=this.editor.getModel().getLanguageId();if(!t)return;const i=this.languageConfigurationService.getLanguageConfiguration(t).comments,s=this.languageConfigurationService.getLanguageConfiguration(t).foldingRules;return i||s?.markers?{foldingRules:s,findMarkSectionHeaders:e.showMarkSectionHeaders,findRegionSectionHeaders:e.showRegionSectionHeaders}:void 0}findSectionHeaders(){if(!this.editor.hasModel()||!this.options?.findMarkSectionHeaders&&!this.options?.findRegionSectionHeaders)return;const e=this.editor.getModel();if(e.isDisposed()||e.isTooLargeForSyncing())return;const t=e.getVersionId();this.editorWorkerService.findSectionHeaders(e.uri,this.options).then((i=>{e.isDisposed()||e.getVersionId()!==t||this.updateDecorations(i)}))}updateDecorations(e){const t=this.editor.getModel();t&&(e=e.filter((e=>{if(!e.shouldBeInComments)return!0;const i=t.validateRange(e.range),s=t.tokenization.getLineTokens(i.startLineNumber),n=s.findTokenIndexAtOffset(i.startColumn-1),r=s.getStandardTokenType(n);return s.getLanguageId(n)===t.getLanguageId()&&1===r})));const i=Object.values(this.currentOccurrences).map((e=>e.decorationId)),s=e.map((e=>function(e){return{range:e.range,options:a.kI.createDynamic({description:"section-header",stickiness:3,collapseOnReplaceEdit:!0,minimap:{color:void 0,position:1,sectionHeaderStyle:e.hasSeparatorLine?2:1,sectionHeaderText:e.text}})}}(e)));this.editor.changeDecorations((t=>{const n=t.deltaDecorations(i,s);this.currentOccurrences={};for(let i=0,s=n.length;i{"use strict";var s,n=i(5662),r=i(64383),o=i(23750),a=i(84001),l=i(90766),c=i(18447),h=i(47612),d=i(45538),u=i(32371),g=i(32500),p=i(78381),m=i(56942),f=i(74243),_=i(72466),v=i(84585),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},b=function(e,t){return function(i,s){t(i,s,e)}};let E=class extends n.jG{constructor(e,t,i,s,n,r){super(),this._watchers=Object.create(null);const o=t=>{this._watchers[t.uri.toString()]=new S(t,e,i,n,r)},a=(e,t)=>{t.dispose(),delete this._watchers[e.uri.toString()]},l=()=>{for(const e of t.getModels()){const t=this._watchers[e.uri.toString()];(0,v.K)(e,i,s)?t||o(e):t&&a(e,t)}};t.getModels().forEach((e=>{(0,v.K)(e,i,s)&&o(e)})),this._register(t.onModelAdded((e=>{(0,v.K)(e,i,s)&&o(e)}))),this._register(t.onModelRemoved((e=>{const t=this._watchers[e.uri.toString()];t&&a(e,t)}))),this._register(s.onDidChangeConfiguration((e=>{e.affectsConfiguration(v.r)&&l()}))),this._register(i.onDidColorThemeChange(l))}dispose(){for(const e of Object.values(this._watchers))e.dispose();super.dispose()}};E=C([b(0,f.ISemanticTokensStylingService),b(1,o.IModelService),b(2,h.Gy),b(3,a.pG),b(4,g.ILanguageFeatureDebounceService),b(5,m.ILanguageFeaturesService)],E);let S=class extends n.jG{static{s=this}static{this.REQUEST_MIN_DELAY=300}static{this.REQUEST_MAX_DELAY=2e3}constructor(e,t,i,r,o){super(),this._semanticTokensStylingService=t,this._isDisposed=!1,this._model=e,this._provider=o.documentSemanticTokensProvider,this._debounceInformation=r.for(this._provider,"DocumentSemanticTokens",{min:s.REQUEST_MIN_DELAY,max:s.REQUEST_MAX_DELAY}),this._fetchDocumentSemanticTokens=this._register(new l.uC((()=>this._fetchDocumentSemanticTokensNow()),s.REQUEST_MIN_DELAY)),this._currentDocumentResponse=null,this._currentDocumentRequestCancellationTokenSource=null,this._documentProvidersChangeListeners=[],this._providersChangedDuringRequest=!1,this._register(this._model.onDidChangeContent((()=>{this._fetchDocumentSemanticTokens.isScheduled()||this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._register(this._model.onDidChangeAttached((()=>{this._fetchDocumentSemanticTokens.isScheduled()||this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._register(this._model.onDidChangeLanguage((()=>{this._currentDocumentResponse&&(this._currentDocumentResponse.dispose(),this._currentDocumentResponse=null),this._currentDocumentRequestCancellationTokenSource&&(this._currentDocumentRequestCancellationTokenSource.cancel(),this._currentDocumentRequestCancellationTokenSource=null),this._setDocumentSemanticTokens(null,null,null,[]),this._fetchDocumentSemanticTokens.schedule(0)})));const a=()=>{(0,n.AS)(this._documentProvidersChangeListeners),this._documentProvidersChangeListeners=[];for(const t of this._provider.all(e))"function"===typeof t.onDidChange&&this._documentProvidersChangeListeners.push(t.onDidChange((()=>{this._currentDocumentRequestCancellationTokenSource?this._providersChangedDuringRequest=!0:this._fetchDocumentSemanticTokens.schedule(0)})))};a(),this._register(this._provider.onDidChange((()=>{a(),this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._register(i.onDidColorThemeChange((e=>{this._setDocumentSemanticTokens(null,null,null,[]),this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))}))),this._fetchDocumentSemanticTokens.schedule(0)}dispose(){this._currentDocumentResponse&&(this._currentDocumentResponse.dispose(),this._currentDocumentResponse=null),this._currentDocumentRequestCancellationTokenSource&&(this._currentDocumentRequestCancellationTokenSource.cancel(),this._currentDocumentRequestCancellationTokenSource=null),(0,n.AS)(this._documentProvidersChangeListeners),this._documentProvidersChangeListeners=[],this._setDocumentSemanticTokens(null,null,null,[]),this._isDisposed=!0,super.dispose()}_fetchDocumentSemanticTokensNow(){if(this._currentDocumentRequestCancellationTokenSource)return;if(!(0,u.br)(this._provider,this._model))return void(this._currentDocumentResponse&&this._model.tokenization.setSemanticTokens(null,!1));if(!this._model.isAttachedToEditor())return;const e=new c.Qi,t=this._currentDocumentResponse?this._currentDocumentResponse.provider:null,i=this._currentDocumentResponse&&this._currentDocumentResponse.resultId||null,s=(0,u.aw)(this._provider,this._model,t,i,e.token);this._currentDocumentRequestCancellationTokenSource=e,this._providersChangedDuringRequest=!1;const n=[],o=this._model.onDidChangeContent((e=>{n.push(e)})),a=new p.W(!1);s.then((e=>{if(this._debounceInformation.update(this._model,a.elapsed()),this._currentDocumentRequestCancellationTokenSource=null,o.dispose(),e){const{provider:t,tokens:i}=e,s=this._semanticTokensStylingService.getStyling(t);this._setDocumentSemanticTokens(t,i||null,s,n)}else this._setDocumentSemanticTokens(null,null,null,n)}),(e=>{e&&(r.MB(e)||"string"===typeof e.message&&-1!==e.message.indexOf("busy"))||r.dz(e),this._currentDocumentRequestCancellationTokenSource=null,o.dispose(),(n.length>0||this._providersChangedDuringRequest)&&(this._fetchDocumentSemanticTokens.isScheduled()||this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model)))}))}static _copy(e,t,i,s,n){n=Math.min(n,i.length-s,e.length-t);for(let r=0;r{(n.length>0||this._providersChangedDuringRequest)&&!this._fetchDocumentSemanticTokens.isScheduled()&&this._fetchDocumentSemanticTokens.schedule(this._debounceInformation.get(this._model))};if(this._currentDocumentResponse&&(this._currentDocumentResponse.dispose(),this._currentDocumentResponse=null),this._isDisposed)e&&t&&e.releaseDocumentSemanticTokens(t.resultId);else if(e&&i){if(!t)return this._model.tokenization.setSemanticTokens(null,!0),void o();if((0,u.yS)(t)){if(!r)return void this._model.tokenization.setSemanticTokens(null,!0);if(0===t.edits.length)t={resultId:t.resultId,data:r.data};else{let e=0;for(const i of t.edits)e+=(i.data?i.data.length:0)-i.deleteCount;const n=r.data,o=new Uint32Array(n.length+e);let a=n.length,l=o.length;for(let c=t.edits.length-1;c>=0;c--){const e=t.edits[c];if(e.start>n.length)return i.warnInvalidEditStart(r.resultId,t.resultId,c,e.start,n.length),void this._model.tokenization.setSemanticTokens(null,!0);const h=a-(e.start+e.deleteCount);h>0&&(s._copy(n,a-h,o,l-h,h),l-=h),e.data&&(s._copy(e.data,0,o,l-e.data.length,e.data.length),l-=e.data.length),a=e.start}a>0&&s._copy(n,0,o,0,a),t={resultId:t.resultId,data:o}}}if((0,u.BB)(t)){this._currentDocumentResponse=new y(e,t.resultId,t.data);const s=(0,d.toMultilineTokens2)(t,i,this._model.getLanguageId());if(n.length>0)for(const e of n)for(const t of s)for(const i of e.changes)t.applyEdit(i.range,i.text);this._model.tokenization.setSemanticTokens(s,!0)}else this._model.tokenization.setSemanticTokens(null,!0);o()}else this._model.tokenization.setSemanticTokens(null,!1)}};S=s=C([b(1,f.ISemanticTokensStylingService),b(2,h.Gy),b(3,g.ILanguageFeatureDebounceService),b(4,m.ILanguageFeaturesService)],S);class y{constructor(e,t,i){this.provider=e,this.resultId=t,this.data=i}dispose(){this.provider.releaseDocumentSemanticTokens(this.resultId)}}(0,_.x)(E)},44798:(e,t,i)=>{"use strict";var s=i(90766),n=i(5662),r=i(31450),o=i(32371),a=i(84585),l=i(45538),c=i(84001),h=i(47612),d=i(32500),u=i(78381),g=i(56942),p=i(74243),m=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},f=function(e,t){return function(i,s){t(i,s,e)}};let _=class extends n.jG{static{this.ID="editor.contrib.viewportSemanticTokens"}constructor(e,t,i,n,r,o){super(),this._semanticTokensStylingService=t,this._themeService=i,this._configurationService=n,this._editor=e,this._provider=o.documentRangeSemanticTokensProvider,this._debounceInformation=r.for(this._provider,"DocumentRangeSemanticTokens",{min:100,max:500}),this._tokenizeViewport=this._register(new s.uC((()=>this._tokenizeViewportNow()),100)),this._outstandingRequests=[];const l=()=>{this._editor.hasModel()&&this._tokenizeViewport.schedule(this._debounceInformation.get(this._editor.getModel()))};this._register(this._editor.onDidScrollChange((()=>{l()}))),this._register(this._editor.onDidChangeModel((()=>{this._cancelAll(),l()}))),this._register(this._editor.onDidChangeModelContent((e=>{this._cancelAll(),l()}))),this._register(this._provider.onDidChange((()=>{this._cancelAll(),l()}))),this._register(this._configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration(a.r)&&(this._cancelAll(),l())}))),this._register(this._themeService.onDidColorThemeChange((()=>{this._cancelAll(),l()}))),l()}_cancelAll(){for(const e of this._outstandingRequests)e.cancel();this._outstandingRequests=[]}_removeOutstandingRequest(e){for(let t=0,i=this._outstandingRequests.length;tthis._requestRange(e,t))))}_requestRange(e,t){const i=e.getVersionId(),n=(0,s.SS)((i=>Promise.resolve((0,o.nZ)(this._provider,e,t,i)))),r=new u.W(!1);return n.then((s=>{if(this._debounceInformation.update(e,r.elapsed()),!s||!s.tokens||e.isDisposed()||e.getVersionId()!==i)return;const{provider:n,tokens:o}=s,a=this._semanticTokensStylingService.getStyling(n);e.tokenization.setPartialSemanticTokens(t,(0,l.toMultilineTokens2)(o,a,e.getLanguageId()))})).then((()=>this._removeOutstandingRequest(n)),(()=>this._removeOutstandingRequest(n))),n}};_=m([f(1,p.ISemanticTokensStylingService),f(2,h.Gy),f(3,c.pG),f(4,d.ILanguageFeatureDebounceService),f(5,g.ILanguageFeaturesService)],_),(0,r.HW)(_.ID,_,1)},32371:(e,t,i)=>{"use strict";i.d(t,{BB:()=>u,WG:()=>v,aw:()=>f,br:()=>m,nZ:()=>b,yS:()=>g});var s=i(18447),n=i(64383),r=i(79400),o=i(23750),a=i(50091),l=i(631),c=i(98232),h=i(36677),d=i(56942);function u(e){return e&&!!e.data}function g(e){return e&&Array.isArray(e.edits)}class p{constructor(e,t,i){this.provider=e,this.tokens=t,this.error=i}}function m(e,t){return e.has(t)}async function f(e,t,i,s,n){const r=function(e,t){const i=e.orderedGroups(t);return i.length>0?i[0]:[]}(e,t),o=await Promise.all(r.map((async e=>{let r,o=null;try{r=await e.provideDocumentSemanticTokens(t,e===i?s:null,n)}catch(a){o=a,r=null}return r&&(u(r)||g(r))||(r=null),new p(e,r,o)})));for(const a of o){if(a.error)throw a.error;if(a.tokens)return a}return o.length>0?o[0]:null}class _{constructor(e,t){this.provider=e,this.tokens=t}}function v(e,t){return e.has(t)}function C(e,t){const i=e.orderedGroups(t);return i.length>0?i[0]:[]}async function b(e,t,i,s){const r=C(e,t),o=await Promise.all(r.map((async e=>{let r;try{r=await e.provideDocumentRangeSemanticTokens(t,i,s)}catch(o){(0,n.M_)(o),r=null}return r&&u(r)||(r=null),new _(e,r)})));for(const n of o)if(n.tokens)return n;return o.length>0?o[0]:null}a.w.registerCommand("_provideDocumentSemanticTokensLegend",(async(e,...t)=>{const[i]=t;(0,l.j)(i instanceof r.r);const s=e.get(o.IModelService).getModel(i);if(!s)return;const{documentSemanticTokensProvider:n}=e.get(d.ILanguageFeaturesService),c=function(e,t){const i=e.orderedGroups(t);return i.length>0?i[0]:null}(n,s);return c?c[0].getLegend():e.get(a.d).executeCommand("_provideDocumentRangeSemanticTokensLegend",i)})),a.w.registerCommand("_provideDocumentSemanticTokens",(async(e,...t)=>{const[i]=t;(0,l.j)(i instanceof r.r);const n=e.get(o.IModelService).getModel(i);if(!n)return;const{documentSemanticTokensProvider:h}=e.get(d.ILanguageFeaturesService);if(!m(h,n))return e.get(a.d).executeCommand("_provideDocumentRangeSemanticTokens",i,n.getFullModelRange());const g=await f(h,n,null,null,s.XO.None);if(!g)return;const{provider:p,tokens:_}=g;if(!_||!u(_))return;const v=(0,c.encodeSemanticTokensDto)({id:0,type:"full",data:_.data});return _.resultId&&p.releaseDocumentSemanticTokens(_.resultId),v})),a.w.registerCommand("_provideDocumentRangeSemanticTokensLegend",(async(e,...t)=>{const[i,n]=t;(0,l.j)(i instanceof r.r);const a=e.get(o.IModelService).getModel(i);if(!a)return;const{documentRangeSemanticTokensProvider:c}=e.get(d.ILanguageFeaturesService),u=C(c,a);if(0===u.length)return;if(1===u.length)return u[0].getLegend();if(!n||!h.Q.isIRange(n))return console.warn("provideDocumentRangeSemanticTokensLegend might be out-of-sync with provideDocumentRangeSemanticTokens unless a range argument is passed in"),u[0].getLegend();const g=await b(c,a,h.Q.lift(n),s.XO.None);return g?g.provider.getLegend():void 0})),a.w.registerCommand("_provideDocumentRangeSemanticTokens",(async(e,...t)=>{const[i,n]=t;(0,l.j)(i instanceof r.r),(0,l.j)(h.Q.isIRange(n));const a=e.get(o.IModelService).getModel(i);if(!a)return;const{documentRangeSemanticTokensProvider:u}=e.get(d.ILanguageFeaturesService),g=await b(u,a,h.Q.lift(n),s.XO.None);return g&&g.tokens?(0,c.encodeSemanticTokensDto)({id:0,type:"full",data:g.tokens.data}):void 0}))},84585:(e,t,i)=>{"use strict";i.d(t,{K:()=>n,r:()=>s});const s="editor.semanticHighlighting";function n(e,t,i){const n=i.getValue(s,{overrideIdentifier:e.getLanguageId(),resource:e.uri})?.enabled;return"boolean"===typeof n?n:t.getColorTheme().semanticHighlighting}},39286:(e,t,i)=>{"use strict";i.d(t,{n:()=>o});var s=i(58925),n=i(83069),r=i(36677);class o{async provideSelectionRanges(e,t){const i=[];for(const s of t){const t=[];i.push(t);const n=new Map;await new Promise((t=>o._bracketsRightYield(t,0,e,s,n))),await new Promise((i=>o._bracketsLeftYield(i,0,e,s,n,t)))}return i}static{this._maxDuration=30}static{this._maxRounds=2}static _bracketsRightYield(e,t,i,n,r){const a=new Map,l=Date.now();for(;;){if(t>=o._maxRounds){e();break}if(!n){e();break}const c=i.bracketPairs.findNextBracket(n);if(!c){e();break}if(Date.now()-l>o._maxDuration){setTimeout((()=>o._bracketsRightYield(e,t+1,i,n,r)));break}if(c.bracketInfo.isOpeningBracket){const e=c.bracketInfo.bracketText,t=a.has(e)?a.get(e):0;a.set(e,t+1)}else{const e=c.bracketInfo.getOpeningBrackets()[0].bracketText;let t=a.has(e)?a.get(e):0;if(t-=1,a.set(e,Math.max(0,t)),t<0){let t=r.get(e);t||(t=new s.w,r.set(e,t)),t.push(c.range)}}n=c.range.getEndPosition()}}static _bracketsLeftYield(e,t,i,s,n,a){const l=new Map,c=Date.now();for(;;){if(t>=o._maxRounds&&0===n.size){e();break}if(!s){e();break}const h=i.bracketPairs.findPrevBracket(s);if(!h){e();break}if(Date.now()-c>o._maxDuration){setTimeout((()=>o._bracketsLeftYield(e,t+1,i,s,n,a)));break}if(h.bracketInfo.isOpeningBracket){const e=h.bracketInfo.bracketText;let t=l.has(e)?l.get(e):0;if(t-=1,l.set(e,Math.max(0,t)),t<0){const t=n.get(e);if(t){const s=t.shift();0===t.size&&n.delete(e);const l=r.Q.fromPositions(h.range.getEndPosition(),s.getStartPosition()),c=r.Q.fromPositions(h.range.getStartPosition(),s.getEndPosition());a.push({range:l}),a.push({range:c}),o._addBracketLeading(i,c,a)}}}else{const e=h.bracketInfo.getOpeningBrackets()[0].bracketText,t=l.has(e)?l.get(e):0;l.set(e,t+1)}s=h.range.getStartPosition()}}static _addBracketLeading(e,t,i){if(t.startLineNumber===t.endLineNumber)return;const s=t.startLineNumber,o=e.getLineFirstNonWhitespaceColumn(s);0!==o&&o!==t.startColumn&&(i.push({range:r.Q.fromPositions(new n.y(s,o),t.getEndPosition())}),i.push({range:r.Q.fromPositions(new n.y(s,1),t.getEndPosition())}));const a=s-1;if(a>0){const s=e.getLineFirstNonWhitespaceColumn(a);s===t.startColumn&&s!==e.getLineLastNonWhitespaceColumn(a)&&(i.push({range:r.Q.fromPositions(new n.y(a,s),t.getEndPosition())}),i.push({range:r.Q.fromPositions(new n.y(a,1),t.getEndPosition())}))}}}},10617:(e,t,i)=>{"use strict";var s=i(25890),n=i(18447),r=i(64383),o=i(31450),a=i(83069),l=i(36677),c=i(75326),h=i(60002),d=i(39286),u=i(91508);class g{constructor(e=!0){this.selectSubwords=e}provideSelectionRanges(e,t){const i=[];for(const s of t){const t=[];i.push(t),this.selectSubwords&&this._addInWordRanges(t,e,s),this._addWordRanges(t,e,s),this._addWhitespaceLine(t,e,s),t.push({range:e.getFullModelRange()})}return i}_addInWordRanges(e,t,i){const s=t.getWordAtPosition(i);if(!s)return;const{word:n,startColumn:r}=s,o=i.column-r;let a=o,c=o,h=0;for(;a>=0;a--){const e=n.charCodeAt(a);if(a!==o&&(95===e||45===e))break;if((0,u.Lv)(e)&&(0,u.Wv)(h))break;h=e}for(a+=1;c0&&0===t.getLineFirstNonWhitespaceColumn(i.lineNumber)&&0===t.getLineLastNonWhitespaceColumn(i.lineNumber)&&e.push({range:new l.Q(i.lineNumber,1,i.lineNumber,t.getLineMaxColumn(i.lineNumber))})}}var p,m=i(78209),f=i(27195),_=i(50091),v=i(56942),C=i(18938),b=i(631),E=i(79400),S=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},y=function(e,t){return function(i,s){t(i,s,e)}};class w{constructor(e,t){this.index=e,this.ranges=t}mov(e){const t=this.index+(e?1:-1);if(t<0||t>=this.ranges.length)return this;const i=new w(t,this.ranges);return i.ranges[t].equalsRange(this.ranges[this.index])?i.mov(e):i}}let L=class{static{p=this}static{this.ID="editor.contrib.smartSelectController"}static get(e){return e.getContribution(p.ID)}constructor(e,t){this._editor=e,this._languageFeaturesService=t,this._ignoreSelection=!1}dispose(){this._selectionListener?.dispose()}async run(e){if(!this._editor.hasModel())return;const t=this._editor.getSelections(),i=this._editor.getModel();if(this._state||await T(this._languageFeaturesService.selectionRangeProvider,i,t.map((e=>e.getPosition())),this._editor.getOption(114),n.XO.None).then((e=>{if(s.EI(e)&&e.length===t.length&&this._editor.hasModel()&&s.aI(this._editor.getSelections(),t,((e,t)=>e.equalsSelection(t)))){for(let i=0;ie.containsPosition(t[i].getStartPosition())&&e.containsPosition(t[i].getEndPosition()))),e[i].unshift(t[i]);this._state=e.map((e=>new w(0,e))),this._selectionListener?.dispose(),this._selectionListener=this._editor.onDidChangeCursorPosition((()=>{this._ignoreSelection||(this._selectionListener?.dispose(),this._state=void 0)}))}})),!this._state)return;this._state=this._state.map((t=>t.mov(e)));const r=this._state.map((e=>c.L.fromPositions(e.ranges[e.index].getStartPosition(),e.ranges[e.index].getEndPosition())));this._ignoreSelection=!0;try{this._editor.setSelections(r)}finally{this._ignoreSelection=!1}}};L=p=S([y(1,v.ILanguageFeaturesService)],L);class R extends o.ks{constructor(e,t){super(t),this._forward=e}async run(e,t){const i=L.get(t);i&&await i.run(this._forward)}}_.w.registerCommandAlias("editor.action.smartSelect.grow","editor.action.smartSelect.expand");async function T(e,t,i,n,o){const c=e.all(t).concat(new g(n.selectSubwords));1===c.length&&c.unshift(new d.n);const h=[],u=[];for(const a of c)h.push(Promise.resolve(a.provideSelectionRanges(t,i,o)).then((e=>{if(s.EI(e)&&e.length===i.length)for(let t=0;t{if(0===e.length)return[];e.sort(((e,t)=>a.y.isBefore(e.getStartPosition(),t.getStartPosition())?1:a.y.isBefore(t.getStartPosition(),e.getStartPosition())||a.y.isBefore(e.getEndPosition(),t.getEndPosition())?-1:a.y.isBefore(t.getEndPosition(),e.getEndPosition())?1:0));const i=[];let s;for(const t of e)(!s||l.Q.containsRange(t,s)&&!l.Q.equalsRange(t,s))&&(i.push(t),s=t);if(!n.selectLeadingAndTrailingWhitespace)return i;const r=[i[0]];for(let n=1;n{"use strict";i.d(t,{O:()=>C});var s,n=i(5662),r=i(631),o=i(31450),a=i(83069),l=i(60002),c=i(17469),h=i(56942),d=i(48116),u=i(78209),g=i(32848),p=i(18801),m=i(38280),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};const v={overwriteBefore:0,overwriteAfter:0,undoStopBefore:!0,undoStopAfter:!0,adjustWhitespace:!0,clipboardText:void 0,overtypingCapturer:void 0};let C=class{static{s=this}static{this.ID="snippetController2"}static get(e){return e.getContribution(s.ID)}static{this.InSnippetMode=new g.N1("inSnippetMode",!1,(0,u.kg)("inSnippetMode","Whether the editor in current in snippet mode"))}static{this.HasNextTabstop=new g.N1("hasNextTabstop",!1,(0,u.kg)("hasNextTabstop","Whether there is a next tab stop when in snippet mode"))}static{this.HasPrevTabstop=new g.N1("hasPrevTabstop",!1,(0,u.kg)("hasPrevTabstop","Whether there is a previous tab stop when in snippet mode"))}constructor(e,t,i,r,o){this._editor=e,this._logService=t,this._languageFeaturesService=i,this._languageConfigurationService=o,this._snippetListener=new n.Cm,this._modelVersionId=-1,this._inSnippet=s.InSnippetMode.bindTo(r),this._hasNextTabstop=s.HasNextTabstop.bindTo(r),this._hasPrevTabstop=s.HasPrevTabstop.bindTo(r)}dispose(){this._inSnippet.reset(),this._hasPrevTabstop.reset(),this._hasNextTabstop.reset(),this._session?.dispose(),this._snippetListener.dispose()}insert(e,t){try{this._doInsert(e,"undefined"===typeof t?v:{...v,...t})}catch(i){this.cancel(),this._logService.error(i),this._logService.error("snippet_error"),this._logService.error("insert_template=",e),this._logService.error("existing_template=",this._session?this._session._logInfo():"")}}_doInsert(e,t){if(this._editor.hasModel()){if(this._snippetListener.clear(),t.undoStopBefore&&this._editor.getModel().pushStackElement(),this._session&&"string"!==typeof e&&this.cancel(),this._session?((0,r.j)("string"===typeof e),this._session.merge(e,t)):(this._modelVersionId=this._editor.getModel().getAlternativeVersionId(),this._session=new m.O(this._editor,e,t,this._languageConfigurationService),this._session.insert()),t.undoStopAfter&&this._editor.getModel().pushStackElement(),this._session?.hasChoice){const e={_debugDisplayName:"snippetChoiceCompletions",provideCompletionItems:(e,t)=>{if(!this._session||e!==this._editor.getModel()||!a.y.equals(this._editor.getPosition(),t))return;const{activeChoice:i}=this._session;if(!i||0===i.choice.options.length)return;const s=e.getValueInRange(i.range),n=Boolean(i.choice.options.find((e=>e.value===s))),r=[];for(let o=0;o{i?.dispose(),s=!1},r=()=>{s||(i=this._languageFeaturesService.completionProvider.register({language:t.getLanguageId(),pattern:t.uri.fsPath,scheme:t.uri.scheme,exclusive:!0},e),this._snippetListener.add(i),s=!0)};this._choiceCompletions={provider:e,enable:r,disable:n}}this._updateState(),this._snippetListener.add(this._editor.onDidChangeModelContent((e=>e.isFlush&&this.cancel()))),this._snippetListener.add(this._editor.onDidChangeModel((()=>this.cancel()))),this._snippetListener.add(this._editor.onDidChangeCursorSelection((()=>this._updateState())))}}_updateState(){if(this._session&&this._editor.hasModel()){if(this._modelVersionId===this._editor.getModel().getAlternativeVersionId())return this.cancel();if(!this._session.hasPlaceholder)return this.cancel();if(this._session.isAtLastPlaceholder||!this._session.isSelectionWithinPlaceholders())return this._editor.getModel().pushStackElement(),this.cancel();this._inSnippet.set(!0),this._hasPrevTabstop.set(!this._session.isAtFirstPlaceholder),this._hasNextTabstop.set(!this._session.isAtLastPlaceholder),this._handleChoice()}}_handleChoice(){if(!this._session||!this._editor.hasModel())return void(this._currentChoice=void 0);const{activeChoice:e}=this._session;if(!e||!this._choiceCompletions)return this._choiceCompletions?.disable(),void(this._currentChoice=void 0);this._currentChoice!==e.choice&&(this._currentChoice=e.choice,this._choiceCompletions.enable(),queueMicrotask((()=>{(0,d.p3)(this._editor,this._choiceCompletions.provider)})))}finish(){for(;this._inSnippet.get();)this.next()}cancel(e=!1){this._inSnippet.reset(),this._hasPrevTabstop.reset(),this._hasNextTabstop.reset(),this._snippetListener.clear(),this._currentChoice=void 0,this._session?.dispose(),this._session=void 0,this._modelVersionId=-1,e&&this._editor.setSelections([this._editor.getSelection()])}prev(){this._session?.prev(),this._updateState()}next(){this._session?.next(),this._updateState()}isInSnippet(){return Boolean(this._inSnippet.get())}};C=s=f([_(1,p.rr),_(2,h.ILanguageFeaturesService),_(3,g.fN),_(4,c.JZ)],C),(0,o.HW)(C.ID,C,4);const b=o.DX.bindToContribution(C.get);(0,o.E_)(new b({id:"jumpToNextSnippetPlaceholder",precondition:g.M$.and(C.InSnippetMode,C.HasNextTabstop),handler:e=>e.next(),kbOpts:{weight:130,kbExpr:l.R.textInputFocus,primary:2}})),(0,o.E_)(new b({id:"jumpToPrevSnippetPlaceholder",precondition:g.M$.and(C.InSnippetMode,C.HasPrevTabstop),handler:e=>e.prev(),kbOpts:{weight:130,kbExpr:l.R.textInputFocus,primary:1026}})),(0,o.E_)(new b({id:"leaveSnippet",precondition:C.InSnippetMode,handler:e=>e.cancel(!0),kbOpts:{weight:130,kbExpr:l.R.textInputFocus,primary:9,secondary:[1033]}})),(0,o.E_)(new b({id:"acceptSnippet",precondition:C.InSnippetMode,handler:e=>e.finish()}))},29319:(e,t,i)=>{"use strict";i.d(t,{EY:()=>r,GR:()=>l,Or:()=>a,fr:()=>p,mQ:()=>g});class s{constructor(){this.value="",this.pos=0}static{this._table={36:0,58:1,44:2,123:3,125:4,92:5,47:6,124:7,43:11,45:12,63:13}}static isDigitCharacter(e){return e>=48&&e<=57}static isVariableCharacter(e){return 95===e||e>=97&&e<=122||e>=65&&e<=90}text(e){this.value=e,this.pos=0}tokenText(e){return this.value.substr(e.pos,e.len)}next(){if(this.pos>=this.value.length)return{type:14,pos:this.pos,len:0};const e=this.pos;let t,i=0,n=this.value.charCodeAt(e);if(t=s._table[n],"number"===typeof t)return this.pos+=1,{type:t,pos:e,len:1};if(s.isDigitCharacter(n)){t=8;do{i+=1,n=this.value.charCodeAt(e+i)}while(s.isDigitCharacter(n));return this.pos+=i,{type:t,pos:e,len:i}}if(s.isVariableCharacter(n)){t=9;do{n=this.value.charCodeAt(e+ ++i)}while(s.isVariableCharacter(n)||s.isDigitCharacter(n));return this.pos+=i,{type:t,pos:e,len:i}}t=10;do{i+=1,n=this.value.charCodeAt(e+i)}while(!isNaN(n)&&"undefined"===typeof s._table[n]&&!s.isDigitCharacter(n)&&!s.isVariableCharacter(n));return this.pos+=i,{type:t,pos:e,len:i}}}class n{constructor(){this._children=[]}appendChild(e){return e instanceof r&&this._children[this._children.length-1]instanceof r?this._children[this._children.length-1].value+=e.value:(e.parent=this,this._children.push(e)),this}replace(e,t){const{parent:i}=e,s=i.children.indexOf(e),n=i.children.slice(0);n.splice(s,1,...t),i._children=n,function e(t,i){for(const s of t)s.parent=i,e(s.children,s)}(t,i)}get children(){return this._children}get rightMostDescendant(){return this._children.length>0?this._children[this._children.length-1].rightMostDescendant:this}get snippet(){let e=this;for(;;){if(!e)return;if(e instanceof g)return e;e=e.parent}}toString(){return this.children.reduce(((e,t)=>e+t.toString()),"")}len(){return 0}}class r extends n{constructor(e){super(),this.value=e}toString(){return this.value}len(){return this.value.length}clone(){return new r(this.value)}}class o extends n{}class a extends o{static compareByIndex(e,t){return e.index===t.index?0:e.isFinalTabstop?1:t.isFinalTabstop||e.indext.index?1:0}constructor(e){super(),this.index=e}get isFinalTabstop(){return 0===this.index}get choice(){return 1===this._children.length&&this._children[0]instanceof l?this._children[0]:void 0}clone(){const e=new a(this.index);return this.transform&&(e.transform=this.transform.clone()),e._children=this.children.map((e=>e.clone())),e}}class l extends n{constructor(){super(...arguments),this.options=[]}appendChild(e){return e instanceof r&&(e.parent=this,this.options.push(e)),this}toString(){return this.options[0].value}len(){return this.options[0].len()}clone(){const e=new l;return this.options.forEach(e.appendChild,e),e}}class c extends n{constructor(){super(...arguments),this.regexp=new RegExp("")}resolve(e){const t=this;let i=!1,s=e.replace(this.regexp,(function(){return i=!0,t._replace(Array.prototype.slice.call(arguments,0,-2))}));return!i&&this._children.some((e=>e instanceof h&&Boolean(e.elseValue)))&&(s=this._replace([])),s}_replace(e){let t="";for(const i of this._children)if(i instanceof h){let s=e[i.index]||"";s=i.resolve(s),t+=s}else t+=i.toString();return t}toString(){return""}clone(){const e=new c;return e.regexp=new RegExp(this.regexp.source,(this.regexp.ignoreCase?"i":"")+(this.regexp.global?"g":"")),e._children=this.children.map((e=>e.clone())),e}}class h extends n{constructor(e,t,i,s){super(),this.index=e,this.shorthandName=t,this.ifValue=i,this.elseValue=s}resolve(e){return"upcase"===this.shorthandName?e?e.toLocaleUpperCase():"":"downcase"===this.shorthandName?e?e.toLocaleLowerCase():"":"capitalize"===this.shorthandName?e?e[0].toLocaleUpperCase()+e.substr(1):"":"pascalcase"===this.shorthandName?e?this._toPascalCase(e):"":"camelcase"===this.shorthandName?e?this._toCamelCase(e):"":Boolean(e)&&"string"===typeof this.ifValue?this.ifValue:Boolean(e)||"string"!==typeof this.elseValue?e||"":this.elseValue}_toPascalCase(e){const t=e.match(/[a-z0-9]+/gi);return t?t.map((e=>e.charAt(0).toUpperCase()+e.substr(1))).join(""):e}_toCamelCase(e){const t=e.match(/[a-z0-9]+/gi);return t?t.map(((e,t)=>0===t?e.charAt(0).toLowerCase()+e.substr(1):e.charAt(0).toUpperCase()+e.substr(1))).join(""):e}clone(){return new h(this.index,this.shorthandName,this.ifValue,this.elseValue)}}class d extends o{constructor(e){super(),this.name=e}resolve(e){let t=e.resolve(this);return this.transform&&(t=this.transform.resolve(t||"")),void 0!==t&&(this._children=[new r(t)],!0)}clone(){const e=new d(this.name);return this.transform&&(e.transform=this.transform.clone()),e._children=this.children.map((e=>e.clone())),e}}function u(e,t){const i=[...e];for(;i.length>0;){const e=i.shift();if(!t(e))break;i.unshift(...e.children)}}class g extends n{get placeholderInfo(){if(!this._placeholders){const e=[];let t;this.walk((function(i){return i instanceof a&&(e.push(i),t=!t||t.indexs===e?(i=!0,!1):(t+=s.len(),!0))),i?t:-1}fullLen(e){let t=0;return u([e],(e=>(t+=e.len(),!0))),t}enclosingPlaceholders(e){const t=[];let{parent:i}=e;for(;i;)i instanceof a&&t.push(i),i=i.parent;return t}resolveVariables(e){return this.walk((t=>(t instanceof d&&t.resolve(e)&&(this._placeholders=void 0),!0))),this}appendChild(e){return this._placeholders=void 0,super.appendChild(e)}replace(e,t){return this._placeholders=void 0,super.replace(e,t)}clone(){const e=new g;return this._children=this.children.map((e=>e.clone())),e}walk(e){u(this.children,e)}}class p{constructor(){this._scanner=new s,this._token={type:14,pos:0,len:0}}static escape(e){return e.replace(/\$|}|\\/g,"\\$&")}static guessNeedsClipboard(e){return/\${?CLIPBOARD/.test(e)}parse(e,t,i){const s=new g;return this.parseFragment(e,s),this.ensureFinalTabstop(s,i??!1,t??!1),s}parseFragment(e,t){const i=t.children.length;for(this._scanner.text(e),this._token=this._scanner.next();this._parse(t););const s=new Map,n=[];t.walk((e=>(e instanceof a&&(e.isFinalTabstop?s.set(0,void 0):!s.has(e.index)&&e.children.length>0?s.set(e.index,e.children):n.push(e)),!0)));const r=(e,i)=>{const n=s.get(e.index);if(!n)return;const o=new a(e.index);o.transform=e.transform;for(const t of n){const e=t.clone();o.appendChild(e),e instanceof a&&s.has(e.index)&&!i.has(e.index)&&(i.add(e.index),r(e,i),i.delete(e.index))}t.replace(e,[o])},o=new Set;for(const a of n)r(a,o);return t.children.slice(i)}ensureFinalTabstop(e,t,i){if(t||i&&e.placeholders.length>0){e.placeholders.find((e=>0===e.index))||e.appendChild(new a(0))}}_accept(e,t){if(void 0===e||this._token.type===e){const e=!t||this._scanner.tokenText(this._token);return this._token=this._scanner.next(),e}return!1}_backTo(e){return this._scanner.pos=e.pos+e.len,this._token=e,!1}_until(e){const t=this._token;for(;this._token.type!==e;){if(14===this._token.type)return!1;if(5===this._token.type){const e=this._scanner.next();if(0!==e.type&&4!==e.type&&5!==e.type)return!1}this._token=this._scanner.next()}const i=this._scanner.value.substring(t.pos,this._token.pos).replace(/\\(\$|}|\\)/g,"$1");return this._token=this._scanner.next(),i}_parse(e){return this._parseEscaped(e)||this._parseTabstopOrVariableName(e)||this._parseComplexPlaceholder(e)||this._parseComplexVariable(e)||this._parseAnything(e)}_parseEscaped(e){let t;return!!(t=this._accept(5,!0))&&(t=this._accept(0,!0)||this._accept(4,!0)||this._accept(5,!0)||t,e.appendChild(new r(t)),!0)}_parseTabstopOrVariableName(e){let t;const i=this._token;return this._accept(0)&&(t=this._accept(9,!0)||this._accept(8,!0))?(e.appendChild(/^\d+$/.test(t)?new a(Number(t)):new d(t)),!0):this._backTo(i)}_parseComplexPlaceholder(e){let t;const i=this._token;if(!(this._accept(0)&&this._accept(3)&&(t=this._accept(8,!0))))return this._backTo(i);const s=new a(Number(t));if(this._accept(1))for(;;){if(this._accept(4))return e.appendChild(s),!0;if(!this._parse(s))return e.appendChild(new r("${"+t+":")),s.children.forEach(e.appendChild,e),!0}else{if(!(s.index>0&&this._accept(7)))return this._accept(6)?this._parseTransform(s)?(e.appendChild(s),!0):(this._backTo(i),!1):this._accept(4)?(e.appendChild(s),!0):this._backTo(i);{const t=new l;for(;;){if(this._parseChoiceElement(t)){if(this._accept(2))continue;if(this._accept(7)&&(s.appendChild(t),this._accept(4)))return e.appendChild(s),!0}return this._backTo(i),!1}}}}_parseChoiceElement(e){const t=this._token,i=[];for(;2!==this._token.type&&7!==this._token.type;){let e;if(e=(e=this._accept(5,!0))?this._accept(2,!0)||this._accept(7,!0)||this._accept(5,!0)||e:this._accept(void 0,!0),!e)return this._backTo(t),!1;i.push(e)}return 0===i.length?(this._backTo(t),!1):(e.appendChild(new r(i.join(""))),!0)}_parseComplexVariable(e){let t;const i=this._token;if(!(this._accept(0)&&this._accept(3)&&(t=this._accept(9,!0))))return this._backTo(i);const s=new d(t);if(!this._accept(1))return this._accept(6)?this._parseTransform(s)?(e.appendChild(s),!0):(this._backTo(i),!1):this._accept(4)?(e.appendChild(s),!0):this._backTo(i);for(;;){if(this._accept(4))return e.appendChild(s),!0;if(!this._parse(s))return e.appendChild(new r("${"+t+":")),s.children.forEach(e.appendChild,e),!0}}_parseTransform(e){const t=new c;let i="",s="";for(;!this._accept(6);){let e;if(e=this._accept(5,!0))e=this._accept(6,!0)||e,i+=e;else{if(14===this._token.type)return!1;i+=this._accept(void 0,!0)}}for(;!this._accept(6);){let e;if(e=this._accept(5,!0))e=this._accept(5,!0)||this._accept(6,!0)||e,t.appendChild(new r(e));else if(!this._parseFormatString(t)&&!this._parseAnything(t))return!1}for(;!this._accept(4);){if(14===this._token.type)return!1;s+=this._accept(void 0,!0)}try{t.regexp=new RegExp(i,s)}catch(n){return!1}return e.transform=t,!0}_parseFormatString(e){const t=this._token;if(!this._accept(0))return!1;let i=!1;this._accept(3)&&(i=!0);const s=this._accept(8,!0);if(!s)return this._backTo(t),!1;if(!i)return e.appendChild(new h(Number(s))),!0;if(this._accept(4))return e.appendChild(new h(Number(s))),!0;if(!this._accept(1))return this._backTo(t),!1;if(this._accept(6)){const i=this._accept(9,!0);return i&&this._accept(4)?(e.appendChild(new h(Number(s),i)),!0):(this._backTo(t),!1)}if(this._accept(11)){const t=this._until(4);if(t)return e.appendChild(new h(Number(s),void 0,t,void 0)),!0}else if(this._accept(12)){const t=this._until(4);if(t)return e.appendChild(new h(Number(s),void 0,void 0,t)),!0}else if(this._accept(13)){const t=this._until(1);if(t){const i=this._until(4);if(i)return e.appendChild(new h(Number(s),void 0,t,i)),!0}}else{const t=this._until(4);if(t)return e.appendChild(new h(Number(s),void 0,void 0,t)),!0}return this._backTo(t),!1}_parseAnything(e){return 14!==this._token.type&&(e.appendChild(new r(this._scanner.tokenText(this._token))),this._accept(void 0),!0)}}},38280:(e,t,i)=>{"use strict";i.d(t,{O:()=>P});var s=i(25890),n=i(5662),r=i(91508),o=i(7085),a=i(36677),l=i(75326),c=i(17469),h=i(87289),d=i(67841),u=i(37227),g=i(29319),p=i(79326),m=i(98067);function f(e,t=m.uF){return(0,p.No)(e,t)?e.charAt(0).toUpperCase()+e.slice(1):e}Object.create(null);var _=i(74027),v=i(89403),C=i(58255),b=i(78209),E=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},S=function(e,t){return function(i,s){t(i,s,e)}};Object.freeze({CURRENT_YEAR:!0,CURRENT_YEAR_SHORT:!0,CURRENT_MONTH:!0,CURRENT_DATE:!0,CURRENT_HOUR:!0,CURRENT_MINUTE:!0,CURRENT_SECOND:!0,CURRENT_DAY_NAME:!0,CURRENT_DAY_NAME_SHORT:!0,CURRENT_MONTH_NAME:!0,CURRENT_MONTH_NAME_SHORT:!0,CURRENT_SECONDS_UNIX:!0,CURRENT_TIMEZONE_OFFSET:!0,SELECTION:!0,CLIPBOARD:!0,TM_SELECTED_TEXT:!0,TM_CURRENT_LINE:!0,TM_CURRENT_WORD:!0,TM_LINE_INDEX:!0,TM_LINE_NUMBER:!0,TM_FILENAME:!0,TM_FILENAME_BASE:!0,TM_DIRECTORY:!0,TM_FILEPATH:!0,CURSOR_INDEX:!0,CURSOR_NUMBER:!0,RELATIVE_FILEPATH:!0,BLOCK_COMMENT_START:!0,BLOCK_COMMENT_END:!0,LINE_COMMENT:!0,WORKSPACE_NAME:!0,WORKSPACE_FOLDER:!0,RANDOM:!0,RANDOM_HEX:!0,UUID:!0});class y{constructor(e){this._delegates=e}resolve(e){for(const t of this._delegates){const i=t.resolve(e);if(void 0!==i)return i}}}class w{constructor(e,t,i,s){this._model=e,this._selection=t,this._selectionIdx=i,this._overtypingCapturer=s}resolve(e){const{name:t}=e;if("SELECTION"===t||"TM_SELECTED_TEXT"===t){let t=this._model.getValueInRange(this._selection)||void 0,i=this._selection.startLineNumber!==this._selection.endLineNumber;if(!t&&this._overtypingCapturer){const e=this._overtypingCapturer.getLastOvertypedInfo(this._selectionIdx);e&&(t=e.value,i=e.multiline)}if(t&&i&&e.snippet){const i=this._model.getLineContent(this._selection.startLineNumber),s=(0,r.UU)(i,0,this._selection.startColumn-1);let n=s;e.snippet.walk((t=>t!==e&&(t instanceof g.EY&&(n=(0,r.UU)((0,r.uz)(t.value).pop())),!0)));const o=(0,r.Qp)(n,s);t=t.replace(/(\r\n|\r|\n)(.*)/g,((e,t,i)=>`${t}${n.substr(o)}${i}`))}return t}if("TM_CURRENT_LINE"===t)return this._model.getLineContent(this._selection.positionLineNumber);if("TM_CURRENT_WORD"===t){const e=this._model.getWordAtPosition({lineNumber:this._selection.positionLineNumber,column:this._selection.positionColumn});return e&&e.word||void 0}return"TM_LINE_INDEX"===t?String(this._selection.positionLineNumber-1):"TM_LINE_NUMBER"===t?String(this._selection.positionLineNumber):"CURSOR_INDEX"===t?String(this._selectionIdx):"CURSOR_NUMBER"===t?String(this._selectionIdx+1):void 0}}class L{constructor(e,t){this._labelService=e,this._model=t}resolve(e){const{name:t}=e;if("TM_FILENAME"===t)return _.P8(this._model.uri.fsPath);if("TM_FILENAME_BASE"===t){const e=_.P8(this._model.uri.fsPath),t=e.lastIndexOf(".");return t<=0?e:e.slice(0,t)}return"TM_DIRECTORY"===t?"."===_.pD(this._model.uri.fsPath)?"":this._labelService.getUriLabel((0,v.pD)(this._model.uri)):"TM_FILEPATH"===t?this._labelService.getUriLabel(this._model.uri):"RELATIVE_FILEPATH"===t?this._labelService.getUriLabel(this._model.uri,{relative:!0,noPrefix:!0}):void 0}}class R{constructor(e,t,i,s){this._readClipboardText=e,this._selectionIdx=t,this._selectionCount=i,this._spread=s}resolve(e){if("CLIPBOARD"!==e.name)return;const t=this._readClipboardText();if(t){if(this._spread){const e=t.split(/\r\n|\n|\r/).filter((e=>!(0,r.AV)(e)));if(e.length===this._selectionCount)return e[this._selectionIdx]}return t}}}let T=class{constructor(e,t,i){this._model=e,this._selection=t,this._languageConfigurationService=i}resolve(e){const{name:t}=e,i=this._model.getLanguageIdAtPosition(this._selection.selectionStartLineNumber,this._selection.selectionStartColumn),s=this._languageConfigurationService.getLanguageConfiguration(i).comments;if(s)return"LINE_COMMENT"===t?s.lineCommentToken||void 0:"BLOCK_COMMENT_START"===t?s.blockCommentStartToken||void 0:"BLOCK_COMMENT_END"===t&&s.blockCommentEndToken||void 0}};T=E([S(2,c.JZ)],T);class x{constructor(){this._date=new Date}static{this.dayNames=[b.kg("Sunday","Sunday"),b.kg("Monday","Monday"),b.kg("Tuesday","Tuesday"),b.kg("Wednesday","Wednesday"),b.kg("Thursday","Thursday"),b.kg("Friday","Friday"),b.kg("Saturday","Saturday")]}static{this.dayNamesShort=[b.kg("SundayShort","Sun"),b.kg("MondayShort","Mon"),b.kg("TuesdayShort","Tue"),b.kg("WednesdayShort","Wed"),b.kg("ThursdayShort","Thu"),b.kg("FridayShort","Fri"),b.kg("SaturdayShort","Sat")]}static{this.monthNames=[b.kg("January","January"),b.kg("February","February"),b.kg("March","March"),b.kg("April","April"),b.kg("May","May"),b.kg("June","June"),b.kg("July","July"),b.kg("August","August"),b.kg("September","September"),b.kg("October","October"),b.kg("November","November"),b.kg("December","December")]}static{this.monthNamesShort=[b.kg("JanuaryShort","Jan"),b.kg("FebruaryShort","Feb"),b.kg("MarchShort","Mar"),b.kg("AprilShort","Apr"),b.kg("MayShort","May"),b.kg("JuneShort","Jun"),b.kg("JulyShort","Jul"),b.kg("AugustShort","Aug"),b.kg("SeptemberShort","Sep"),b.kg("OctoberShort","Oct"),b.kg("NovemberShort","Nov"),b.kg("DecemberShort","Dec")]}resolve(e){const{name:t}=e;if("CURRENT_YEAR"===t)return String(this._date.getFullYear());if("CURRENT_YEAR_SHORT"===t)return String(this._date.getFullYear()).slice(-2);if("CURRENT_MONTH"===t)return String(this._date.getMonth().valueOf()+1).padStart(2,"0");if("CURRENT_DATE"===t)return String(this._date.getDate().valueOf()).padStart(2,"0");if("CURRENT_HOUR"===t)return String(this._date.getHours().valueOf()).padStart(2,"0");if("CURRENT_MINUTE"===t)return String(this._date.getMinutes().valueOf()).padStart(2,"0");if("CURRENT_SECOND"===t)return String(this._date.getSeconds().valueOf()).padStart(2,"0");if("CURRENT_DAY_NAME"===t)return x.dayNames[this._date.getDay()];if("CURRENT_DAY_NAME_SHORT"===t)return x.dayNamesShort[this._date.getDay()];if("CURRENT_MONTH_NAME"===t)return x.monthNames[this._date.getMonth()];if("CURRENT_MONTH_NAME_SHORT"===t)return x.monthNamesShort[this._date.getMonth()];if("CURRENT_SECONDS_UNIX"===t)return String(Math.floor(this._date.getTime()/1e3));if("CURRENT_TIMEZONE_OFFSET"===t){const e=this._date.getTimezoneOffset(),t=e>0?"-":"+",i=Math.trunc(Math.abs(e/60)),s=i<10?"0"+i:i,n=Math.abs(e)-60*i;return t+s+":"+(n<10?"0"+n:n)}}}class k{constructor(e){this._workspaceService=e}resolve(e){if(!this._workspaceService)return;const t=(0,u.Q_)(this._workspaceService.getWorkspace());return(0,u.A7)(t)?void 0:"WORKSPACE_NAME"===e.name?this._resolveWorkspaceName(t):"WORKSPACE_FOLDER"===e.name?this._resoveWorkspacePath(t):void 0}_resolveWorkspaceName(e){if((0,u.jB)(e))return _.P8(e.uri.path);let t=_.P8(e.configPath.path);return t.endsWith(u.kF)&&(t=t.substr(0,t.length-u.kF.length-1)),t}_resoveWorkspacePath(e){if((0,u.jB)(e))return f(e.uri.fsPath);const t=_.P8(e.configPath.path);let i=e.configPath.fsPath;return i.endsWith(t)&&(i=i.substr(0,i.length-t.length-1)),i?f(i):"/"}}class A{resolve(e){const{name:t}=e;return"RANDOM"===t?Math.random().toString().slice(-6):"RANDOM_HEX"===t?Math.random().toString(16).slice(-6):"UUID"===t?(0,C.b)():void 0}}var N,I=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},O=function(e,t){return function(i,s){t(i,s,e)}};class D{static{this._decor={active:h.kI.register({description:"snippet-placeholder-1",stickiness:0,className:"snippet-placeholder"}),inactive:h.kI.register({description:"snippet-placeholder-2",stickiness:1,className:"snippet-placeholder"}),activeFinal:h.kI.register({description:"snippet-placeholder-3",stickiness:1,className:"finish-snippet-placeholder"}),inactiveFinal:h.kI.register({description:"snippet-placeholder-4",stickiness:1,className:"finish-snippet-placeholder"})}}constructor(e,t,i){this._editor=e,this._snippet=t,this._snippetLineLeadingWhitespace=i,this._offset=-1,this._nestingLevel=1,this._placeholderGroups=(0,s.$z)(t.placeholders,g.Or.compareByIndex),this._placeholderGroupsIdx=-1}initialize(e){this._offset=e.newPosition}dispose(){this._placeholderDecorations&&this._editor.removeDecorations([...this._placeholderDecorations.values()]),this._placeholderGroups.length=0}_initDecorations(){if(-1===this._offset)throw new Error("Snippet not initialized!");if(this._placeholderDecorations)return;this._placeholderDecorations=new Map;const e=this._editor.getModel();this._editor.changeDecorations((t=>{for(const i of this._snippet.placeholders){const s=this._snippet.offset(i),n=this._snippet.fullLen(i),r=a.Q.fromPositions(e.getPositionAt(this._offset+s),e.getPositionAt(this._offset+s+n)),o=i.isFinalTabstop?D._decor.inactiveFinal:D._decor.inactive,l=t.addDecoration(r,o);this._placeholderDecorations.set(i,l)}}))}move(e){if(!this._editor.hasModel())return[];if(this._initDecorations(),this._placeholderGroupsIdx>=0){const e=[];for(const t of this._placeholderGroups[this._placeholderGroupsIdx])if(t.transform){const i=this._placeholderDecorations.get(t),s=this._editor.getModel().getDecorationRange(i),n=this._editor.getModel().getValueInRange(s),r=t.transform.resolve(n).split(/\r\n|\r|\n/);for(let e=1;e0&&this._editor.executeEdits("snippet.placeholderTransform",e)}let t=!1;!0===e&&this._placeholderGroupsIdx0&&(this._placeholderGroupsIdx-=1,t=!0);const i=this._editor.getModel().changeDecorations((e=>{const i=new Set,s=[];for(const n of this._placeholderGroups[this._placeholderGroupsIdx]){const r=this._placeholderDecorations.get(n),o=this._editor.getModel().getDecorationRange(r);s.push(new l.L(o.startLineNumber,o.startColumn,o.endLineNumber,o.endColumn)),t=t&&this._hasPlaceholderBeenCollapsed(n),e.changeDecorationOptions(r,n.isFinalTabstop?D._decor.activeFinal:D._decor.active),i.add(n);for(const t of this._snippet.enclosingPlaceholders(n)){const s=this._placeholderDecorations.get(t);e.changeDecorationOptions(s,t.isFinalTabstop?D._decor.activeFinal:D._decor.active),i.add(t)}}for(const[t,n]of this._placeholderDecorations)i.has(t)||e.changeDecorationOptions(n,t.isFinalTabstop?D._decor.inactiveFinal:D._decor.inactive);return s}));return t?this.move(e):i??[]}_hasPlaceholderBeenCollapsed(e){let t=e;for(;t;){if(t instanceof g.Or){const e=this._placeholderDecorations.get(t);if(this._editor.getModel().getDecorationRange(e).isEmpty()&&t.toString().length>0)return!0}t=t.parent}return!1}get isAtFirstPlaceholder(){return this._placeholderGroupsIdx<=0||0===this._placeholderGroups.length}get isAtLastPlaceholder(){return this._placeholderGroupsIdx===this._placeholderGroups.length-1}get hasPlaceholder(){return this._snippet.placeholders.length>0}get isTrivialSnippet(){if(0===this._snippet.placeholders.length)return!0;if(1===this._snippet.placeholders.length){const[e]=this._snippet.placeholders;if(e.isFinalTabstop&&this._snippet.rightMostDescendant===e)return!0}return!1}computePossibleSelections(){const e=new Map;for(const t of this._placeholderGroups){let i;for(const s of t){if(s.isFinalTabstop)break;i||(i=[],e.set(s.index,i));const t=this._placeholderDecorations.get(s),n=this._editor.getModel().getDecorationRange(t);if(!n){e.delete(s.index);break}i.push(n)}}return e}get activeChoice(){if(!this._placeholderDecorations)return;const e=this._placeholderGroups[this._placeholderGroupsIdx][0];if(!e?.choice)return;const t=this._placeholderDecorations.get(e);if(!t)return;const i=this._editor.getModel().getDecorationRange(t);return i?{range:i,choice:e.choice}:void 0}get hasChoice(){let e=!1;return this._snippet.walk((t=>(e=t instanceof g.GR,!e))),e}merge(e){const t=this._editor.getModel();this._nestingLevel*=10,this._editor.changeDecorations((i=>{for(const s of this._placeholderGroups[this._placeholderGroupsIdx]){const n=e.shift();console.assert(-1!==n._offset),console.assert(!n._placeholderDecorations);const r=n._snippet.placeholderInfo.last.index;for(const e of n._snippet.placeholderInfo.all)e.isFinalTabstop?e.index=s.index+(r+1)/this._nestingLevel:e.index=s.index+e.index/this._nestingLevel;this._snippet.replace(s,n._snippet.children);const o=this._placeholderDecorations.get(s);i.removeDecoration(o),this._placeholderDecorations.delete(s);for(const e of n._snippet.placeholders){const s=n._snippet.offset(e),r=n._snippet.fullLen(e),o=a.Q.fromPositions(t.getPositionAt(n._offset+s),t.getPositionAt(n._offset+s+r)),l=i.addDecoration(o,D._decor.inactive);this._placeholderDecorations.set(e,l)}}this._placeholderGroups=(0,s.$z)(this._snippet.placeholders,g.Or.compareByIndex)}))}}const M={overwriteBefore:0,overwriteAfter:0,adjustWhitespace:!0,clipboardText:void 0,overtypingCapturer:void 0};let P=N=class{static adjustWhitespace(e,t,i,s,n){const o=e.getLineContent(t.lineNumber),a=(0,r.UU)(o,0,t.column-1);let l;return s.walk((t=>{if(!(t instanceof g.EY)||t.parent instanceof g.GR)return!0;if(n&&!n.has(t))return!0;const r=t.value.split(/\r\n|\r|\n/);if(i){const i=s.offset(t);if(0===i)r[0]=e.normalizeIndentation(r[0]);else{l=l??s.toString();const t=l.charCodeAt(i-1);10!==t&&13!==t||(r[0]=e.normalizeIndentation(a+r[0]))}for(let t=1;te.get(u.VR))),v=e.invokeWithinContext((e=>new L(e.get(d.L),f))),C=()=>l,b=f.getValueInRange(N.adjustSelection(f,e.getSelection(),i,0)),E=f.getValueInRange(N.adjustSelection(f,e.getSelection(),0,s)),S=f.getLineFirstNonWhitespaceColumn(e.getSelection().positionLineNumber),I=e.getSelections().map(((e,t)=>({selection:e,idx:t}))).sort(((e,t)=>a.Q.compareRangesUsingStarts(e.selection,t.selection)));for(const{selection:a,idx:d}of I){let l=N.adjustSelection(f,a,i,0),u=N.adjustSelection(f,a,0,s);b!==f.getValueInRange(l)&&(l=a),E!==f.getValueInRange(u)&&(u=a);const L=a.setStartPosition(l.startLineNumber,l.startColumn).setEndPosition(u.endLineNumber,u.endColumn),O=(new g.fr).parse(t,!0,n),M=L.getStartPosition(),P=N.adjustWhitespace(f,M,r||d>0&&S!==f.getLineFirstNonWhitespaceColumn(a.positionLineNumber),O);O.resolveVariables(new y([v,new R(C,d,I.length,"spread"===e.getOption(79)),new w(f,a,d,c),new T(f,a,h),new x,new k(_),new A])),p[d]=o.k.replace(L,O.toString()),p[d].identifier={major:d,minor:0},p[d]._isTracked=!0,m[d]=new D(e,O,P)}return{edits:p,snippets:m}}static createEditsAndSnippetsFromEdits(e,t,i,s,n,r,l){if(!e.hasModel()||0===t.length)return{edits:[],snippets:[]};const c=[],h=e.getModel(),p=new g.fr,m=new g.mQ,f=new y([e.invokeWithinContext((e=>new L(e.get(d.L),h))),new R((()=>n),0,e.getSelections().length,"spread"===e.getOption(79)),new w(h,e.getSelection(),0,r),new T(h,e.getSelection(),l),new x,new k(e.invokeWithinContext((e=>e.get(u.VR)))),new A]);t=t.sort(((e,t)=>a.Q.compareRangesUsingStarts(e.range,t.range)));let _=0;for(let d=0;d0){const i=t[d-1].range,s=a.Q.fromPositions(i.getEndPosition(),e.getStartPosition()),n=new g.EY(h.getValueInRange(s));m.appendChild(n),_+=n.value.length}const s=p.parseFragment(i,m);N.adjustWhitespace(h,e.getStartPosition(),!0,m,new Set(s)),m.resolveVariables(f);const n=m.toString(),r=n.slice(_);_=n.length;const l=o.k.replace(e,r);l.identifier={major:d,minor:0},l._isTracked=!0,c.push(l)}return p.ensureFinalTabstop(m,i,!0),{edits:c,snippets:[new D(e,m,"")]}}constructor(e,t,i=M,s){this._editor=e,this._template=t,this._options=i,this._languageConfigurationService=s,this._templateMerges=[],this._snippets=[]}dispose(){(0,n.AS)(this._snippets)}_logInfo(){return`template="${this._template}", merged_templates="${this._templateMerges.join(" -> ")}"`}insert(){if(!this._editor.hasModel())return;const{edits:e,snippets:t}="string"===typeof this._template?N.createEditsAndSnippetsFromSelections(this._editor,this._template,this._options.overwriteBefore,this._options.overwriteAfter,!1,this._options.adjustWhitespace,this._options.clipboardText,this._options.overtypingCapturer,this._languageConfigurationService):N.createEditsAndSnippetsFromEdits(this._editor,this._template,!1,this._options.adjustWhitespace,this._options.clipboardText,this._options.overtypingCapturer,this._languageConfigurationService);this._snippets=t,this._editor.executeEdits("snippet",e,(e=>{const i=e.filter((e=>!!e.identifier));for(let s=0;sl.L.fromPositions(e.range.getEndPosition())))})),this._editor.revealRange(this._editor.getSelections()[0])}merge(e,t=M){if(!this._editor.hasModel())return;this._templateMerges.push([this._snippets[0]._nestingLevel,this._snippets[0]._placeholderGroupsIdx,e]);const{edits:i,snippets:s}=N.createEditsAndSnippetsFromSelections(this._editor,e,t.overwriteBefore,t.overwriteAfter,!0,t.adjustWhitespace,t.clipboardText,t.overtypingCapturer,this._languageConfigurationService);this._editor.executeEdits("snippet",i,(e=>{const t=e.filter((e=>!!e.identifier));for(let n=0;nl.L.fromPositions(e.range.getEndPosition())))}))}next(){const e=this._move(!0);this._editor.setSelections(e),this._editor.revealPositionInCenterIfOutsideViewport(e[0].getPosition())}prev(){const e=this._move(!1);this._editor.setSelections(e),this._editor.revealPositionInCenterIfOutsideViewport(e[0].getPosition())}_move(e){const t=[];for(const i of this._snippets){const s=i.move(e);t.push(...s)}return t}get isAtFirstPlaceholder(){return this._snippets[0].isAtFirstPlaceholder}get isAtLastPlaceholder(){return this._snippets[0].isAtLastPlaceholder}get hasPlaceholder(){return this._snippets[0].hasPlaceholder}get hasChoice(){return this._snippets[0].hasChoice}get activeChoice(){return this._snippets[0].activeChoice}isSelectionWithinPlaceholders(){if(!this.hasPlaceholder)return!1;const e=this._editor.getSelections();if(e.length{e.push(...s.get(t))}))}e.sort(a.Q.compareRangesUsingStarts);for(const[i,s]of t)if(s.length===e.length){s.sort(a.Q.compareRangesUsingStarts);for(let n=0;n0}};P=N=I([O(3,c.JZ)],P)},57197:(e,t,i)=>{"use strict";var s=i(31450),n=i(78209);const r=Object.freeze({View:(0,n.aS)("view","View"),Help:(0,n.aS)("help","Help"),Test:(0,n.aS)("test","Test"),File:(0,n.aS)("file","File"),Preferences:(0,n.aS)("preferences","Preferences"),Developer:(0,n.aS)({key:"developer",comment:["A developer on Code itself or someone diagnosing issues in Code"]},"Developer")});var o=i(27195),a=i(84001),l=i(32848),c=i(60002),h=i(5662),d=i(56942),u=i(8597),g=i(80789),p=i(25890),m=i(25689),f=i(92473),_=i(29163),v=i(83069),C=i(99020),b=i(25521),E=i(35600),S=i(46109);class y{constructor(e,t,i,s=null){this.startLineNumbers=e,this.endLineNumbers=t,this.lastLineRelativePosition=i,this.showEndForLine=s}equals(e){return!!e&&this.lastLineRelativePosition===e.lastLineRelativePosition&&this.showEndForLine===e.showEndForLine&&(0,p.aI)(this.startLineNumbers,e.startLineNumbers)&&(0,p.aI)(this.endLineNumbers,e.endLineNumbers)}static get Empty(){return new y([],[],0)}}const w=(0,g.H)("stickyScrollViewLayer",{createHTML:e=>e}),L="data-sticky-line-index",R="data-sticky-is-line",T="data-sticky-is-folding-icon";class x extends h.jG{constructor(e){super(),this._editor=e,this._foldingIconStore=new h.Cm,this._rootDomNode=document.createElement("div"),this._lineNumbersDomNode=document.createElement("div"),this._linesDomNodeScrollable=document.createElement("div"),this._linesDomNode=document.createElement("div"),this._lineHeight=this._editor.getOption(67),this._renderedStickyLines=[],this._lineNumbers=[],this._lastLineRelativePosition=0,this._minContentWidthInPx=0,this._isOnGlyphMargin=!1,this._lineNumbersDomNode.className="sticky-widget-line-numbers",this._lineNumbersDomNode.setAttribute("role","none"),this._linesDomNode.className="sticky-widget-lines",this._linesDomNode.setAttribute("role","list"),this._linesDomNodeScrollable.className="sticky-widget-lines-scrollable",this._linesDomNodeScrollable.appendChild(this._linesDomNode),this._rootDomNode.className="sticky-widget",this._rootDomNode.classList.toggle("peek",e instanceof _.t),this._rootDomNode.appendChild(this._lineNumbersDomNode),this._rootDomNode.appendChild(this._linesDomNodeScrollable);const t=()=>{this._linesDomNode.style.left=this._editor.getOption(116).scrollWithEditor?`-${this._editor.getScrollLeft()}px`:"0px"};this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(116)&&t(),e.hasChanged(67)&&(this._lineHeight=this._editor.getOption(67))}))),this._register(this._editor.onDidScrollChange((e=>{e.scrollLeftChanged&&t(),e.scrollWidthChanged&&this._updateWidgetWidth()}))),this._register(this._editor.onDidChangeModel((()=>{t(),this._updateWidgetWidth()}))),this._register(this._foldingIconStore),t(),this._register(this._editor.onDidLayoutChange((e=>{this._updateWidgetWidth()}))),this._updateWidgetWidth()}get lineNumbers(){return this._lineNumbers}get lineNumberCount(){return this._lineNumbers.length}getRenderedStickyLine(e){return this._renderedStickyLines.find((t=>t.lineNumber===e))}getCurrentLines(){return this._lineNumbers}setState(e,t,i){if(void 0===i&&(!this._previousState&&!e||this._previousState&&this._previousState.equals(e)))return;const s=this._isWidgetHeightZero(e),n=s?void 0:e,r=s?0:this._findLineToRebuildWidgetFrom(e,i);this._renderRootNode(n,t,r),this._previousState=e}_isWidgetHeightZero(e){if(!e)return!0;const t=e.startLineNumbers.length*this._lineHeight+e.lastLineRelativePosition;if(t>0){this._lastLineRelativePosition=e.lastLineRelativePosition;const t=[...e.startLineNumbers];null!==e.showEndForLine&&(t[e.showEndForLine]=e.endLineNumbers[e.showEndForLine]),this._lineNumbers=t}else this._lastLineRelativePosition=0,this._lineNumbers=[];return 0===t}_findLineToRebuildWidgetFrom(e,t){if(!e||!this._previousState)return 0;if(void 0!==t)return t;const i=this._previousState,s=e.startLineNumbers.findIndex((e=>!i.startLineNumbers.includes(e)));return-1===s?0:s}_updateWidgetWidth(){const e=this._editor.getLayoutInfo(),t=e.contentLeft;this._lineNumbersDomNode.style.width=`${t}px`,this._linesDomNodeScrollable.style.setProperty("--vscode-editorStickyScroll-scrollableWidth",this._editor.getScrollWidth()-e.verticalScrollbarWidth+"px"),this._rootDomNode.style.width=e.width-e.verticalScrollbarWidth+"px"}_clearStickyLinesFromLine(e){this._foldingIconStore.clear();for(let t=e;te.scrollWidth)))+s.verticalScrollbarWidth,this._editor.layoutOverlayWidget(this)}_setFoldingHoverListeners(){"mouseover"===this._editor.getOption(111)&&(this._foldingIconStore.add(u.ko(this._lineNumbersDomNode,u.Bx.MOUSE_ENTER,(()=>{this._isOnGlyphMargin=!0,this._setFoldingIconsVisibility(!0)}))),this._foldingIconStore.add(u.ko(this._lineNumbersDomNode,u.Bx.MOUSE_LEAVE,(()=>{this._isOnGlyphMargin=!1,this._useFoldingOpacityTransition(!0),this._setFoldingIconsVisibility(!1)}))))}_renderChildNode(e,t,i,s){const n=this._editor._getViewModel();if(!n)return;const r=n.coordinatesConverter.convertModelPositionToViewPosition(new v.y(t,1)).lineNumber,o=n.getViewLineRenderingData(r),a=this._editor.getOption(68);let l;try{l=b.d.filter(o.inlineDecorations,r,o.minColumn,o.maxColumn)}catch(y){l=[]}const c=new E.zL(!0,!0,o.content,o.continuesWithWrappedLine,o.isBasicASCII,o.containsRTL,0,o.tokens,l,o.tabSize,o.startVisibleColumn,1,1,1,500,"none",!0,!0,null),h=new C.fe(2e3),d=(0,E.UW)(c,h);let u;u=w?w.createHTML(h.build()):h.build();const g=document.createElement("span");g.setAttribute(L,String(e)),g.setAttribute(R,""),g.setAttribute("role","listitem"),g.tabIndex=0,g.className="sticky-line-content",g.classList.add(`stickyLine${t}`),g.style.lineHeight=`${this._lineHeight}px`,g.innerHTML=u;const p=document.createElement("span");p.setAttribute(L,String(e)),p.setAttribute("data-sticky-is-line-number",""),p.className="sticky-line-number",p.style.lineHeight=`${this._lineHeight}px`;const m=s.contentLeft;p.style.width=`${m}px`;const f=document.createElement("span");1===a.renderType||3===a.renderType&&t%10===0?f.innerText=t.toString():2===a.renderType&&(f.innerText=Math.abs(t-this._editor.getPosition().lineNumber).toString()),f.className="sticky-line-number-inner",f.style.lineHeight=`${this._lineHeight}px`,f.style.width=`${s.lineNumbersWidth}px`,f.style.paddingLeft=`${s.lineNumbersLeft}px`,p.appendChild(f);const _=this._renderFoldingIconForLine(i,t);_&&p.appendChild(_.domNode),this._editor.applyFontInfo(g),this._editor.applyFontInfo(f),p.style.lineHeight=`${this._lineHeight}px`,g.style.lineHeight=`${this._lineHeight}px`,p.style.height=`${this._lineHeight}px`,g.style.height=`${this._lineHeight}px`;const S=new k(e,t,g,p,_,d.characterMapping,g.scrollWidth);return this._updateTopAndZIndexOfStickyLine(S)}_updateTopAndZIndexOfStickyLine(e){const t=e.index,i=e.lineDomNode,s=e.lineNumberDomNode,n=t===this._lineNumbers.length-1;i.style.zIndex=n?"0":"1",s.style.zIndex=n?"0":"1";const r=`${t*this._lineHeight+this._lastLineRelativePosition+(e.foldingIcon?.isCollapsed?1:0)}px`,o=t*this._lineHeight+"px";return i.style.top=n?r:o,s.style.top=n?r:o,e}_renderFoldingIconForLine(e,t){const i=this._editor.getOption(111);if(!e||"never"===i)return;const s=e.regions,n=s.findRange(t),r=s.getStartLineNumber(n);if(!(t===r))return;const o=s.isCollapsed(n),a=new A(o,r,s.getEndLineNumber(n),this._lineHeight);return a.setVisible(!!this._isOnGlyphMargin||(o||"always"===i)),a.domNode.setAttribute(T,""),a}getId(){return"editor.contrib.stickyScrollWidget"}getDomNode(){return this._rootDomNode}getPosition(){return{preference:2,stackOridinal:10}}getMinContentWidthInPx(){return this._minContentWidthInPx}focusLineWithIndex(e){0<=e&&e0)return null;const t=this._getRenderedStickyLineFromChildDomNode(e);if(!t)return null;const i=(0,f.rk)(t.characterMapping,e,0);return new v.y(t.lineNumber,i)}getLineNumberFromChildDomNode(e){return this._getRenderedStickyLineFromChildDomNode(e)?.lineNumber??null}_getRenderedStickyLineFromChildDomNode(e){const t=this.getLineIndexFromChildDomNode(e);return null===t||t<0||t>=this._renderedStickyLines.length?null:this._renderedStickyLines[t]}getLineIndexFromChildDomNode(e){const t=this._getAttributeValue(e,L);return t?parseInt(t,10):null}isInStickyLine(e){return void 0!==this._getAttributeValue(e,R)}isInFoldingIconDomNode(e){return void 0!==this._getAttributeValue(e,T)}_getAttributeValue(e,t){for(;e&&e!==this._rootDomNode;){const i=e.getAttribute(t);if(null!==i)return i;e=e.parentElement}}}class k{constructor(e,t,i,s,n,r,o){this.index=e,this.lineNumber=t,this.lineDomNode=i,this.lineNumberDomNode=s,this.foldingIcon=n,this.characterMapping=r,this.scrollWidth=o}}class A{constructor(e,t,i,s){this.isCollapsed=e,this.foldingStartLine=t,this.foldingEndLine=i,this.dimension=s,this.domNode=document.createElement("div"),this.domNode.style.width=`${s}px`,this.domNode.style.height=`${s}px`,this.domNode.className=m.L.asClassName(e?S.k0:S.E0)}setVisible(e){this.domNode.style.cursor=e?"pointer":"default",this.domNode.style.opacity=e?"1":"0"}}var N=i(18447),I=i(90766),O=i(41234),D=i(17469),M=i(29999),P=i(44588),F=i(87784),U=i(76495),H=i(64383);class B{constructor(e,t){this.startLineNumber=e,this.endLineNumber=t}}class W{constructor(e,t,i){this.range=e,this.children=t,this.parent=i}}class V{constructor(e,t,i,s){this.uri=e,this.version=t,this.element=i,this.outlineProviderId=s}}var z,G,j=i(42522),K=i(63591),Y=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},q=function(e,t){return function(i,s){t(i,s,e)}};!function(e){e.OUTLINE_MODEL="outlineModel",e.FOLDING_PROVIDER_MODEL="foldingProviderModel",e.INDENTATION_MODEL="indentationModel"}(z||(z={})),function(e){e[e.VALID=0]="VALID",e[e.INVALID=1]="INVALID",e[e.CANCELED=2]="CANCELED"}(G||(G={}));let $=class extends h.jG{constructor(e,t,i,s){switch(super(),this._editor=e,this._modelProviders=[],this._modelPromise=null,this._updateScheduler=this._register(new I.ve(300)),this._updateOperation=this._register(new h.Cm),this._editor.getOption(116).defaultModel){case z.OUTLINE_MODEL:this._modelProviders.push(new X(this._editor,s));case z.FOLDING_PROVIDER_MODEL:this._modelProviders.push(new ee(this._editor,t,s));case z.INDENTATION_MODEL:this._modelProviders.push(new J(this._editor,i))}}dispose(){this._modelProviders.forEach((e=>e.dispose())),this._updateOperation.clear(),this._cancelModelPromise(),super.dispose()}_cancelModelPromise(){this._modelPromise&&(this._modelPromise.cancel(),this._modelPromise=null)}async update(e){return this._updateOperation.clear(),this._updateOperation.add({dispose:()=>{this._cancelModelPromise(),this._updateScheduler.cancel()}}),this._cancelModelPromise(),await this._updateScheduler.trigger((async()=>{for(const t of this._modelProviders){const{statusPromise:i,modelPromise:s}=t.computeStickyModel(e);this._modelPromise=s;const n=await i;if(this._modelPromise!==s)return null;switch(n){case G.CANCELED:return this._updateOperation.clear(),null;case G.VALID:return t.stickyModel}}return null})).catch((e=>((0,H.dz)(e),null)))}};$=Y([q(2,K._Y),q(3,d.ILanguageFeaturesService)],$);class Q extends h.jG{constructor(e){super(),this._editor=e,this._stickyModel=null}get stickyModel(){return this._stickyModel}_invalid(){return this._stickyModel=null,G.INVALID}computeStickyModel(e){if(e.isCancellationRequested||!this.isProviderValid())return{statusPromise:this._invalid(),modelPromise:null};const t=(0,I.SS)((e=>this.createModelFromProvider(e)));return{statusPromise:t.then((t=>this.isModelValid(t)?e.isCancellationRequested?G.CANCELED:(this._stickyModel=this.createStickyModel(e,t),G.VALID):this._invalid())).then(void 0,(e=>((0,H.dz)(e),G.CANCELED))),modelPromise:t}}isModelValid(e){return!0}isProviderValid(){return!0}}let X=class extends Q{constructor(e,t){super(e),this._languageFeaturesService=t}createModelFromProvider(e){return M.i9.create(this._languageFeaturesService.documentSymbolProvider,this._editor.getModel(),e)}createStickyModel(e,t){const{stickyOutlineElement:i,providerID:s}=this._stickyModelFromOutlineModel(t,this._stickyModel?.outlineProviderId),n=this._editor.getModel();return new V(n.uri,n.getVersionId(),i,s)}isModelValid(e){return e&&e.children.size>0}_stickyModelFromOutlineModel(e,t){let i;if(j.f.first(e.children.values())instanceof M.e0){const s=j.f.find(e.children.values(),(e=>e.id===t));if(s)i=s.children;else{let s,n="",r=-1;for(const[t,i]of e.children.entries()){const e=this._findSumOfRangesOfGroup(i);e>r&&(s=i,r=e,n=i.id)}t=n,i=s.children}}else i=e.children;const s=[],n=Array.from(i.values()).sort(((e,t)=>{const i=new B(e.symbol.range.startLineNumber,e.symbol.range.endLineNumber),s=new B(t.symbol.range.startLineNumber,t.symbol.range.endLineNumber);return this._comparator(i,s)}));for(const r of n)s.push(this._stickyModelFromOutlineElement(r,r.symbol.selectionRange.startLineNumber));return{stickyOutlineElement:new W(void 0,s,void 0),providerID:t}}_stickyModelFromOutlineElement(e,t){const i=[];for(const n of e.children.values())if(n.symbol.selectionRange.startLineNumber!==n.symbol.range.endLineNumber)if(n.symbol.selectionRange.startLineNumber!==t)i.push(this._stickyModelFromOutlineElement(n,n.symbol.selectionRange.startLineNumber));else for(const e of n.children.values())i.push(this._stickyModelFromOutlineElement(e,n.symbol.selectionRange.startLineNumber));i.sort(((e,t)=>this._comparator(e.range,t.range)));const s=new B(e.symbol.selectionRange.startLineNumber,e.symbol.range.endLineNumber);return new W(s,i,void 0)}_comparator(e,t){return e.startLineNumber!==t.startLineNumber?e.startLineNumber-t.startLineNumber:t.endLineNumber-e.endLineNumber}_findSumOfRangesOfGroup(e){let t=0;for(const i of e.children.values())t+=this._findSumOfRangesOfGroup(i);return e instanceof M.LC?t+e.symbol.range.endLineNumber-e.symbol.selectionRange.startLineNumber:t}};X=Y([q(1,d.ILanguageFeaturesService)],X);class Z extends Q{constructor(e){super(e),this._foldingLimitReporter=new P.BP(e)}createStickyModel(e,t){const i=this._fromFoldingRegions(t),s=this._editor.getModel();return new V(s.uri,s.getVersionId(),i,void 0)}isModelValid(e){return null!==e}_fromFoldingRegions(e){const t=e.length,i=[],s=new W(void 0,[],void 0);for(let n=0;n0&&(this.provider=this._register(new F.M(e.getModel(),s,t,this._foldingLimitReporter,void 0)))}isProviderValid(){return void 0!==this.provider}async createModelFromProvider(e){return this.provider?.compute(e)??null}};ee=Y([q(2,d.ILanguageFeaturesService)],ee);var te=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ie=function(e,t){return function(i,s){t(i,s,e)}};class se{constructor(e,t,i){this.startLineNumber=e,this.endLineNumber=t,this.nestingDepth=i}}let ne=class extends h.jG{constructor(e,t,i){super(),this._languageFeaturesService=t,this._languageConfigurationService=i,this._onDidChangeStickyScroll=this._register(new O.vl),this.onDidChangeStickyScroll=this._onDidChangeStickyScroll.event,this._model=null,this._cts=null,this._stickyModelProvider=null,this._editor=e,this._sessionStore=this._register(new h.Cm),this._updateSoon=this._register(new I.uC((()=>this.update()),50)),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(116)&&this.readConfiguration()}))),this.readConfiguration()}readConfiguration(){this._sessionStore.clear();this._editor.getOption(116).enabled&&(this._sessionStore.add(this._editor.onDidChangeModel((()=>{this._model=null,this.updateStickyModelProvider(),this._onDidChangeStickyScroll.fire(),this.update()}))),this._sessionStore.add(this._editor.onDidChangeHiddenAreas((()=>this.update()))),this._sessionStore.add(this._editor.onDidChangeModelContent((()=>this._updateSoon.schedule()))),this._sessionStore.add(this._languageFeaturesService.documentSymbolProvider.onDidChange((()=>this.update()))),this._sessionStore.add((0,h.s)((()=>{this._stickyModelProvider?.dispose(),this._stickyModelProvider=null}))),this.updateStickyModelProvider(),this.update())}getVersionId(){return this._model?.version}updateStickyModelProvider(){this._stickyModelProvider?.dispose(),this._stickyModelProvider=null;const e=this._editor;e.hasModel()&&(this._stickyModelProvider=new $(e,(()=>this._updateSoon.schedule()),this._languageConfigurationService,this._languageFeaturesService))}async update(){this._cts?.dispose(!0),this._cts=new N.Qi,await this.updateStickyModel(this._cts.token),this._onDidChangeStickyScroll.fire()}async updateStickyModel(e){if(!this._editor.hasModel()||!this._stickyModelProvider||this._editor.getModel().isTooLargeForTokenization())return void(this._model=null);const t=await this._stickyModelProvider.update(e);e.isCancellationRequested||(this._model=t)}updateIndex(e){return-1===e?e=0:e<0&&(e=-e-2),e}getCandidateStickyLinesIntersectingFromStickyModel(e,t,i,s,n){if(0===t.children.length)return;let r=n;const o=[];for(let c=0;ce-t))),l=this.updateIndex((0,p.El)(o,e.startLineNumber+s,((e,t)=>e-t)));for(let c=a;c<=l;c++){const o=t.children[c];if(!o)return;if(o.range){const t=o.range.startLineNumber,n=o.range.endLineNumber;e.startLineNumber<=n+1&&t-1<=e.endLineNumber&&t!==r&&(r=t,i.push(new se(t,n-1,s+1)),this.getCandidateStickyLinesIntersectingFromStickyModel(e,o,i,s+1,t))}else this.getCandidateStickyLinesIntersectingFromStickyModel(e,o,i,s,n)}}getCandidateStickyLinesIntersecting(e){if(!this._model?.element)return[];let t=[];this.getCandidateStickyLinesIntersectingFromStickyModel(e,this._model.element,t,0,-1);const i=this._editor._getViewModel()?.getHiddenAreas();if(i)for(const s of i)t=t.filter((e=>!(e.startLineNumber>=s.startLineNumber&&e.endLineNumber<=s.endLineNumber+1)));return t}};ne=te([ie(1,d.ILanguageFeaturesService),ie(2,D.JZ)],ne);var re,oe=i(47508),ae=i(37927),le=i(36677),ce=i(80538),he=i(60952),de=i(32500),ue=i(47358),ge=i(52903),pe=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},me=function(e,t){return function(i,s){t(i,s,e)}};let fe=class extends h.jG{static{re=this}static{this.ID="store.contrib.stickyScrollController"}constructor(e,t,i,s,n,r,o){super(),this._editor=e,this._contextMenuService=t,this._languageFeaturesService=i,this._instaService=s,this._contextKeyService=o,this._sessionStore=new h.Cm,this._maxStickyLines=Number.MAX_SAFE_INTEGER,this._candidateDefinitionsLength=-1,this._focusedStickyElementIndex=-1,this._enabled=!1,this._focused=!1,this._positionRevealed=!1,this._onMouseDown=!1,this._endLineNumbers=[],this._stickyScrollWidget=new x(this._editor),this._stickyLineCandidateProvider=new ne(this._editor,i,n),this._register(this._stickyScrollWidget),this._register(this._stickyLineCandidateProvider),this._widgetState=y.Empty,this._onDidResize(),this._readConfiguration();const a=this._stickyScrollWidget.getDomNode();this._register(this._editor.onDidChangeConfiguration((e=>{this._readConfigurationChange(e)}))),this._register(u.ko(a,u.Bx.CONTEXT_MENU,(async e=>{this._onContextMenu(u.zk(a),e)}))),this._stickyScrollFocusedContextKey=c.R.stickyScrollFocused.bindTo(this._contextKeyService),this._stickyScrollVisibleContextKey=c.R.stickyScrollVisible.bindTo(this._contextKeyService);const l=this._register(u.w5(a));this._register(l.onDidBlur((e=>{!1===this._positionRevealed&&0===a.clientHeight?(this._focusedStickyElementIndex=-1,this.focus()):this._disposeFocusStickyScrollStore()}))),this._register(l.onDidFocus((e=>{this.focus()}))),this._registerMouseListeners(),this._register(u.ko(a,u.Bx.MOUSE_DOWN,(e=>{this._onMouseDown=!0})))}static get(e){return e.getContribution(re.ID)}_disposeFocusStickyScrollStore(){this._stickyScrollFocusedContextKey.set(!1),this._focusDisposableStore?.dispose(),this._focused=!1,this._positionRevealed=!1,this._onMouseDown=!1}focus(){if(this._onMouseDown)return this._onMouseDown=!1,void this._editor.focus();!0!==this._stickyScrollFocusedContextKey.get()&&(this._focused=!0,this._focusDisposableStore=new h.Cm,this._stickyScrollFocusedContextKey.set(!0),this._focusedStickyElementIndex=this._stickyScrollWidget.lineNumbers.length-1,this._stickyScrollWidget.focusLineWithIndex(this._focusedStickyElementIndex))}focusNext(){this._focusedStickyElementIndex0&&this._focusNav(!1)}selectEditor(){this._editor.focus()}_focusNav(e){this._focusedStickyElementIndex=e?this._focusedStickyElementIndex+1:this._focusedStickyElementIndex-1,this._stickyScrollWidget.focusLineWithIndex(this._focusedStickyElementIndex)}goToFocused(){const e=this._stickyScrollWidget.lineNumbers;this._disposeFocusStickyScrollStore(),this._revealPosition({lineNumber:e[this._focusedStickyElementIndex],column:1})}_revealPosition(e){this._reveaInEditor(e,(()=>this._editor.revealPosition(e)))}_revealLineInCenterIfOutsideViewport(e){this._reveaInEditor(e,(()=>this._editor.revealLineInCenterIfOutsideViewport(e.lineNumber,0)))}_reveaInEditor(e,t){this._focused&&this._disposeFocusStickyScrollStore(),this._positionRevealed=!0,t(),this._editor.setSelection(le.Q.fromPositions(e)),this._editor.focus()}_registerMouseListeners(){const e=this._register(new h.Cm),t=this._register(new ae.gi(this._editor,{extractLineNumberFromMouseEvent:e=>{const t=this._stickyScrollWidget.getEditorPositionFromNode(e.target.element);return t?t.lineNumber:0}})),i=e=>{if(!this._editor.hasModel())return null;if(12!==e.target.type||e.target.detail!==this._stickyScrollWidget.getId())return null;const t=e.target.element;if(!t||t.innerText!==t.innerHTML)return null;const i=this._stickyScrollWidget.getEditorPositionFromNode(t);return i?{range:new le.Q(i.lineNumber,i.column,i.lineNumber,i.column+t.innerText.length),textElement:t}:null},s=this._stickyScrollWidget.getDomNode();this._register(u.b2(s,u.Bx.CLICK,(e=>{if(e.ctrlKey||e.altKey||e.metaKey)return;if(!e.leftButton)return;if(e.shiftKey){const t=this._stickyScrollWidget.getLineIndexFromChildDomNode(e.target);if(null===t)return;const i=new v.y(this._endLineNumbers[t],1);return void this._revealLineInCenterIfOutsideViewport(i)}if(this._stickyScrollWidget.isInFoldingIconDomNode(e.target)){const t=this._stickyScrollWidget.getLineNumberFromChildDomNode(e.target);return void this._toggleFoldingRegionForLine(t)}if(!this._stickyScrollWidget.isInStickyLine(e.target))return;let t=this._stickyScrollWidget.getEditorPositionFromNode(e.target);if(!t){const i=this._stickyScrollWidget.getLineNumberFromChildDomNode(e.target);if(null===i)return;t=new v.y(i,1)}this._revealPosition(t)}))),this._register(u.b2(s,u.Bx.MOUSE_MOVE,(e=>{if(e.shiftKey){const t=this._stickyScrollWidget.getLineIndexFromChildDomNode(e.target);if(null===t||null!==this._showEndForLine&&this._showEndForLine===t)return;return this._showEndForLine=t,void this._renderStickyScroll()}void 0!==this._showEndForLine&&(this._showEndForLine=void 0,this._renderStickyScroll())}))),this._register(u.ko(s,u.Bx.MOUSE_LEAVE,(e=>{void 0!==this._showEndForLine&&(this._showEndForLine=void 0,this._renderStickyScroll())}))),this._register(t.onMouseMoveOrRelevantKeyDown((([t,s])=>{const n=i(t);if(!n||!t.hasTriggerModifier||!this._editor.hasModel())return void e.clear();const{range:r,textElement:o}=n;if(r.equalsRange(this._stickyRangeProjectedOnEditor)){if("underline"===o.style.textDecoration)return}else this._stickyRangeProjectedOnEditor=r,e.clear();const a=new N.Qi;let l;e.add((0,h.s)((()=>a.dispose(!0)))),(0,ce.hE)(this._languageFeaturesService.definitionProvider,this._editor.getModel(),new v.y(r.startLineNumber,r.startColumn+1),!1,a.token).then((t=>{if(!a.token.isCancellationRequested)if(0!==t.length){this._candidateDefinitionsLength=t.length;const i=o;l!==i?(e.clear(),l=i,l.style.textDecoration="underline",e.add((0,h.s)((()=>{l.style.textDecoration="none"})))):l||(l=i,l.style.textDecoration="underline",e.add((0,h.s)((()=>{l.style.textDecoration="none"}))))}else e.clear()}))}))),this._register(t.onCancel((()=>{e.clear()}))),this._register(t.onExecute((async e=>{if(12!==e.target.type||e.target.detail!==this._stickyScrollWidget.getId())return;const t=this._stickyScrollWidget.getEditorPositionFromNode(e.target.element);t&&this._editor.hasModel()&&this._stickyRangeProjectedOnEditor&&(this._candidateDefinitionsLength>1&&(this._focused&&this._disposeFocusStickyScrollStore(),this._revealPosition({lineNumber:t.lineNumber,column:1})),this._instaService.invokeFunction(he.U,e,this._editor,{uri:this._editor.getModel().uri,range:this._stickyRangeProjectedOnEditor}))})))}_onContextMenu(e,t){const i=new ue.P(e,t);this._contextMenuService.showContextMenu({menuId:o.D8.StickyScrollContext,getAnchor:()=>i})}_toggleFoldingRegionForLine(e){if(!this._foldingModel||null===e)return;const t=this._stickyScrollWidget.getRenderedStickyLine(e),i=t?.foldingIcon;if(!i)return;(0,ge.bC)(this._foldingModel,Number.MAX_VALUE,[e]),i.isCollapsed=!i.isCollapsed;const s=(i.isCollapsed?this._editor.getTopForLineNumber(i.foldingEndLine):this._editor.getTopForLineNumber(i.foldingStartLine))-this._editor.getOption(67)*t.index+1;this._editor.setScrollTop(s),this._renderStickyScroll(e)}_readConfiguration(){const e=this._editor.getOption(116);if(!1===e.enabled)return this._editor.removeOverlayWidget(this._stickyScrollWidget),this._sessionStore.clear(),void(this._enabled=!1);e.enabled&&!this._enabled&&(this._editor.addOverlayWidget(this._stickyScrollWidget),this._sessionStore.add(this._editor.onDidScrollChange((e=>{e.scrollTopChanged&&(this._showEndForLine=void 0,this._renderStickyScroll())}))),this._sessionStore.add(this._editor.onDidLayoutChange((()=>this._onDidResize()))),this._sessionStore.add(this._editor.onDidChangeModelTokens((e=>this._onTokensChange(e)))),this._sessionStore.add(this._stickyLineCandidateProvider.onDidChangeStickyScroll((()=>{this._showEndForLine=void 0,this._renderStickyScroll()}))),this._enabled=!0);2===this._editor.getOption(68).renderType&&this._sessionStore.add(this._editor.onDidChangeCursorPosition((()=>{this._showEndForLine=void 0,this._renderStickyScroll(0)})))}_readConfigurationChange(e){(e.hasChanged(116)||e.hasChanged(73)||e.hasChanged(67)||e.hasChanged(111)||e.hasChanged(68))&&this._readConfiguration(),e.hasChanged(68)&&this._renderStickyScroll(0)}_needsUpdate(e){const t=this._stickyScrollWidget.getCurrentLines();for(const i of t)for(const t of e.ranges)if(i>=t.fromLineNumber&&i<=t.toLineNumber)return!0;return!1}_onTokensChange(e){this._needsUpdate(e)&&this._renderStickyScroll(0)}_onDidResize(){const e=this._editor.getLayoutInfo().height/this._editor.getOption(67);this._maxStickyLines=Math.round(.25*e)}async _renderStickyScroll(e){const t=this._editor.getModel();if(!t||t.isTooLargeForTokenization())return void this._resetState();const i=this._updateAndGetMinRebuildFromLine(e),s=this._stickyLineCandidateProvider.getVersionId();if(void 0===s||s===t.getVersionId())if(this._focused)if(-1===this._focusedStickyElementIndex)await this._updateState(i),this._focusedStickyElementIndex=this._stickyScrollWidget.lineNumberCount-1,-1!==this._focusedStickyElementIndex&&this._stickyScrollWidget.focusLineWithIndex(this._focusedStickyElementIndex);else{const e=this._stickyScrollWidget.lineNumbers[this._focusedStickyElementIndex];if(await this._updateState(i),0===this._stickyScrollWidget.lineNumberCount)this._focusedStickyElementIndex=-1;else{this._stickyScrollWidget.lineNumbers.includes(e)||(this._focusedStickyElementIndex=this._stickyScrollWidget.lineNumberCount-1),this._stickyScrollWidget.focusLineWithIndex(this._focusedStickyElementIndex)}}else await this._updateState(i)}_updateAndGetMinRebuildFromLine(e){if(void 0!==e){const t=void 0!==this._minRebuildFromLine?this._minRebuildFromLine:1/0;this._minRebuildFromLine=Math.min(e,t)}return this._minRebuildFromLine}async _updateState(e){this._minRebuildFromLine=void 0,this._foldingModel=await(P.WR.get(this._editor)?.getFoldingModel())??void 0,this._widgetState=this.findScrollWidgetState();const t=this._widgetState.startLineNumbers.length>0;this._stickyScrollVisibleContextKey.set(t),this._stickyScrollWidget.setState(this._widgetState,this._foldingModel,e)}async _resetState(){this._minRebuildFromLine=void 0,this._foldingModel=void 0,this._widgetState=y.Empty,this._stickyScrollVisibleContextKey.set(!1),this._stickyScrollWidget.setState(void 0,void 0)}findScrollWidgetState(){const e=this._editor.getOption(67),t=Math.min(this._maxStickyLines,this._editor.getOption(116).maxLineCount),i=this._editor.getScrollTop();let s=0;const n=[],r=[],o=this._editor.getVisibleRanges();if(0!==o.length){const a=new B(o[0].startLineNumber,o[o.length-1].endLineNumber),l=this._stickyLineCandidateProvider.getCandidateStickyLinesIntersecting(a);for(const o of l){const a=o.startLineNumber,l=o.endLineNumber,c=o.nestingDepth;if(l-a>0){const o=(c-1)*e,h=c*e,d=this._editor.getBottomForLineNumber(a)-i,u=this._editor.getTopForLineNumber(l)-i,g=this._editor.getBottomForLineNumber(l)-i;if(o>u&&o<=g){n.push(a),r.push(l+1),s=g-h;break}if(h>d&&h<=g&&(n.push(a),r.push(l+1)),n.length===t)break}}}return this._endLineNumbers=r,new y(n,r,s,this._showEndForLine)}dispose(){super.dispose(),this._sessionStore.dispose()}};fe=re=pe([me(1,oe.Z),me(2,d.ILanguageFeaturesService),me(3,K._Y),me(4,D.JZ),me(5,de.ILanguageFeatureDebounceService),me(6,l.fN)],fe);class _e extends o.L{constructor(){super({id:"editor.action.toggleStickyScroll",title:{...(0,n.aS)("toggleEditorStickyScroll","Toggle Editor Sticky Scroll"),mnemonicTitle:(0,n.kg)({key:"mitoggleStickyScroll",comment:["&& denotes a mnemonic"]},"&&Toggle Editor Sticky Scroll")},metadata:{description:(0,n.aS)("toggleEditorStickyScroll.description","Toggle/enable the editor sticky scroll which shows the nested scopes at the top of the viewport")},category:r.View,toggled:{condition:l.M$.equals("config.editor.stickyScroll.enabled",!0),title:(0,n.kg)("stickyScroll","Sticky Scroll"),mnemonicTitle:(0,n.kg)({key:"miStickyScroll",comment:["&& denotes a mnemonic"]},"&&Sticky Scroll")},menu:[{id:o.D8.CommandPalette},{id:o.D8.MenubarAppearanceMenu,group:"4_editor",order:3},{id:o.D8.StickyScrollContext}]})}async run(e){const t=e.get(a.pG),i=!t.getValue("editor.stickyScroll.enabled");return t.updateValue("editor.stickyScroll.enabled",i)}}const ve=100;class Ce extends s.qO{constructor(){super({id:"editor.action.focusStickyScroll",title:{...(0,n.aS)("focusStickyScroll","Focus on the editor sticky scroll"),mnemonicTitle:(0,n.kg)({key:"mifocusStickyScroll",comment:["&& denotes a mnemonic"]},"&&Focus Sticky Scroll")},precondition:l.M$.and(l.M$.has("config.editor.stickyScroll.enabled"),c.R.stickyScrollVisible),menu:[{id:o.D8.CommandPalette}]})}runEditorCommand(e,t){fe.get(t)?.focus()}}class be extends s.qO{constructor(){super({id:"editor.action.selectNextStickyScrollLine",title:(0,n.aS)("selectNextStickyScrollLine.title","Select the next editor sticky scroll line"),precondition:c.R.stickyScrollFocused.isEqualTo(!0),keybinding:{weight:ve,primary:18}})}runEditorCommand(e,t){fe.get(t)?.focusNext()}}class Ee extends s.qO{constructor(){super({id:"editor.action.selectPreviousStickyScrollLine",title:(0,n.aS)("selectPreviousStickyScrollLine.title","Select the previous sticky scroll line"),precondition:c.R.stickyScrollFocused.isEqualTo(!0),keybinding:{weight:ve,primary:16}})}runEditorCommand(e,t){fe.get(t)?.focusPrevious()}}class Se extends s.qO{constructor(){super({id:"editor.action.goToFocusedStickyScrollLine",title:(0,n.aS)("goToFocusedStickyScrollLine.title","Go to the focused sticky scroll line"),precondition:c.R.stickyScrollFocused.isEqualTo(!0),keybinding:{weight:ve,primary:3}})}runEditorCommand(e,t){fe.get(t)?.goToFocused()}}class ye extends s.qO{constructor(){super({id:"editor.action.selectEditor",title:(0,n.aS)("selectEditor.title","Select Editor"),precondition:c.R.stickyScrollFocused.isEqualTo(!0),keybinding:{weight:ve,primary:9}})}runEditorCommand(e,t){fe.get(t)?.selectEditor()}}(0,s.HW)(fe.ID,fe,1),(0,o.ug)(_e),(0,o.ug)(Ce),(0,o.ug)(Ee),(0,o.ug)(be),(0,o.ug)(Se),(0,o.ug)(ye)},51173:(e,t,i)=>{"use strict";i.d(t,{C:()=>a,O:()=>o});var s=i(25890),n=i(26690),r=i(91508);class o{constructor(e,t){this.leadingLineContent=e,this.characterCountDelta=t}}class a{constructor(e,t,i,s,r,o,l=n.Nd.default,c=void 0){this.clipboardText=c,this._snippetCompareFn=a._compareCompletionItems,this._items=e,this._column=t,this._wordDistance=s,this._options=r,this._refilterKind=1,this._lineContext=i,this._fuzzyScoreOptions=l,"top"===o?this._snippetCompareFn=a._compareCompletionItemsSnippetsUp:"bottom"===o&&(this._snippetCompareFn=a._compareCompletionItemsSnippetsDown)}get lineContext(){return this._lineContext}set lineContext(e){this._lineContext.leadingLineContent===e.leadingLineContent&&this._lineContext.characterCountDelta===e.characterCountDelta||(this._refilterKind=this._lineContext.characterCountDelta0&&i[0].container.incomplete&&e.add(t);return e}get stats(){return this._ensureCachedState(),this._stats}_ensureCachedState(){0!==this._refilterKind&&this._createCachedState()}_createCachedState(){this._itemsByProvider=new Map;const e=[],{leadingLineContent:t,characterCountDelta:i}=this._lineContext;let o="",a="";const l=1===this._refilterKind?this._items:this._filteredItems,c=[],h=!this._options.filterGraceful||l.length>2e3?n.dt:n.uU;for(let s=0;s=p)d.score=n.ne.Default;else if("string"===typeof d.completion.filterText){const t=h(o,a,e,d.completion.filterText,d.filterTextLow,0,this._fuzzyScoreOptions);if(!t)continue;0===(0,r.W1)(d.completion.filterText,d.textLabel)?d.score=t:(d.score=(0,n.Jo)(o,a,e,d.textLabel,d.labelLow,0),d.score[0]=t[0])}else{const t=h(o,a,e,d.textLabel,d.labelLow,0,this._fuzzyScoreOptions);if(!t)continue;d.score=t}}d.idx=s,d.distance=this._wordDistance.distance(d.position,d.completion),c.push(d),e.push(d.textLabel.length)}this._filteredItems=c.sort(this._snippetCompareFn),this._refilterKind=0,this._stats={pLabelLen:e.length?(0,s.SO)(e.length-.85,e,((e,t)=>e-t)):0}}static _compareCompletionItems(e,t){return e.score[0]>t.score[0]?-1:e.score[0]t.distance?1:e.idxt.idx?1:0}static _compareCompletionItemsSnippetsDown(e,t){if(e.completion.kind!==t.completion.kind){if(27===e.completion.kind)return 1;if(27===t.completion.kind)return-1}return a._compareCompletionItems(e,t)}static _compareCompletionItemsSnippetsUp(e,t){if(e.completion.kind!==t.completion.kind){if(27===e.completion.kind)return-1;if(27===t.completion.kind)return 1}return a._compareCompletionItems(e,t)}}},48116:(e,t,i)=>{"use strict";i.d(t,{aR:()=>R,dt:()=>b,f3:()=>w,l1:()=>S,ob:()=>C,p3:()=>k,r3:()=>A});var s=i(18447),n=i(64383),r=i(26690),o=i(5662),a=i(78381),l=i(631),c=i(79400),h=i(83069),d=i(36677),u=i(18938),g=i(29319),p=i(78209),m=i(27195),f=i(50091),_=i(32848),v=i(56942);const C={Visible:i(89100).dg,HasFocusedSuggestion:new _.N1("suggestWidgetHasFocusedSuggestion",!1,(0,p.kg)("suggestWidgetHasSelection","Whether any suggestion is focused")),DetailsVisible:new _.N1("suggestWidgetDetailsVisible",!1,(0,p.kg)("suggestWidgetDetailsVisible","Whether suggestion details are visible")),MultipleSuggestions:new _.N1("suggestWidgetMultipleSuggestions",!1,(0,p.kg)("suggestWidgetMultipleSuggestions","Whether there are multiple suggestions to pick from")),MakesTextEdit:new _.N1("suggestionMakesTextEdit",!0,(0,p.kg)("suggestionMakesTextEdit","Whether inserting the current suggestion yields in a change or has everything already been typed")),AcceptSuggestionsOnEnter:new _.N1("acceptSuggestionOnEnter",!0,(0,p.kg)("acceptSuggestionOnEnter","Whether suggestions are inserted when pressing Enter")),HasInsertAndReplaceRange:new _.N1("suggestionHasInsertAndReplaceRange",!1,(0,p.kg)("suggestionHasInsertAndReplaceRange","Whether the current suggestion has insert and replace behaviour")),InsertMode:new _.N1("suggestionInsertMode",void 0,{type:"string",description:(0,p.kg)("suggestionInsertMode","Whether the default behaviour is to insert or replace")}),CanResolve:new _.N1("suggestionCanResolve",!1,(0,p.kg)("suggestionCanResolve","Whether the current suggestion supports to resolve further details"))},b=new m.D8("suggestWidgetStatusBar");class E{constructor(e,t,i,s){this.position=e,this.completion=t,this.container=i,this.provider=s,this.isInvalid=!1,this.score=r.ne.Default,this.distance=0,this.textLabel="string"===typeof t.label?t.label:t.label?.label,this.labelLow=this.textLabel.toLowerCase(),this.isInvalid=!this.textLabel,this.sortTextLow=t.sortText&&t.sortText.toLowerCase(),this.filterTextLow=t.filterText&&t.filterText.toLowerCase(),this.extensionId=t.extensionId,d.Q.isIRange(t.range)?(this.editStart=new h.y(t.range.startLineNumber,t.range.startColumn),this.editInsertEnd=new h.y(t.range.endLineNumber,t.range.endColumn),this.editReplaceEnd=new h.y(t.range.endLineNumber,t.range.endColumn),this.isInvalid=this.isInvalid||d.Q.spansMultipleLines(t.range)||t.range.startLineNumber!==e.lineNumber):(this.editStart=new h.y(t.range.insert.startLineNumber,t.range.insert.startColumn),this.editInsertEnd=new h.y(t.range.insert.endLineNumber,t.range.insert.endColumn),this.editReplaceEnd=new h.y(t.range.replace.endLineNumber,t.range.replace.endColumn),this.isInvalid=this.isInvalid||d.Q.spansMultipleLines(t.range.insert)||d.Q.spansMultipleLines(t.range.replace)||t.range.insert.startLineNumber!==e.lineNumber||t.range.replace.startLineNumber!==e.lineNumber||t.range.insert.startColumn!==t.range.replace.startColumn),"function"!==typeof s.resolveCompletionItem&&(this._resolveCache=Promise.resolve(),this._resolveDuration=0)}get isResolved(){return void 0!==this._resolveDuration}get resolveDuration(){return void 0!==this._resolveDuration?this._resolveDuration:-1}async resolve(e){if(!this._resolveCache){const t=e.onCancellationRequested((()=>{this._resolveCache=void 0,this._resolveDuration=void 0})),i=new a.W(!0);this._resolveCache=Promise.resolve(this.provider.resolveCompletionItem(this.completion,e)).then((e=>{Object.assign(this.completion,e),this._resolveDuration=i.elapsed()}),(e=>{(0,n.MB)(e)&&(this._resolveCache=void 0,this._resolveDuration=void 0)})).finally((()=>{t.dispose()}))}return this._resolveCache}}class S{static{this.default=new S}constructor(e=2,t=new Set,i=new Set,s=new Map,n=!0){this.snippetSortOrder=e,this.kindFilter=t,this.providerFilter=i,this.providerItemsToReuse=s,this.showDeprecated=n}}let y;function w(){return y}class L{constructor(e,t,i,s){this.items=e,this.needsClipboard=t,this.durations=i,this.disposable=s}}async function R(e,t,i,r=S.default,l={triggerKind:0},c=s.XO.None){const h=new a.W;i=i.clone();const u=t.getWordAtPosition(i),p=u?new d.Q(i.lineNumber,u.startColumn,i.lineNumber,u.endColumn):d.Q.fromPositions(i),m={replace:p,insert:p.setEndPosition(i.lineNumber,i.column)},f=[],_=new o.Cm,v=[];let C=!1;const b=(e,t,s)=>{let n=!1;if(!t)return n;for(const o of t.suggestions)if(!r.kindFilter.has(o.kind)){if(!r.showDeprecated&&o?.tags?.includes(1))continue;o.range||(o.range=m),o.sortText||(o.sortText="string"===typeof o.label?o.label:o.label.label),!C&&o.insertTextRules&&4&o.insertTextRules&&(C=g.fr.guessNeedsClipboard(o.insertText)),f.push(new E(i,o,t,e)),n=!0}return(0,o.Xm)(t)&&_.add(t),v.push({providerName:e._debugDisplayName??"unknown_provider",elapsedProvider:t.duration??-1,elapsedOverall:s.elapsed()}),n},w=(async()=>{if(!y||r.kindFilter.has(27))return;const e=r.providerItemsToReuse.get(y);if(e)return void e.forEach((e=>f.push(e)));if(r.providerFilter.size>0&&!r.providerFilter.has(y))return;const s=new a.W,n=await y.provideCompletionItems(t,i,l,c);b(y,n,s)})();for(const s of e.orderedGroups(t)){let e=!1;if(await Promise.all(s.map((async s=>{if(r.providerItemsToReuse.has(s)){const t=r.providerItemsToReuse.get(s);return t.forEach((e=>f.push(e))),void(e=e||t.length>0)}if(!(r.providerFilter.size>0)||r.providerFilter.has(s))try{const n=new a.W,r=await s.provideCompletionItems(t,i,l,c);e=b(s,r,n)||e}catch(o){(0,n.M_)(o)}}))),e||c.isCancellationRequested)break}return await w,c.isCancellationRequested?(_.dispose(),Promise.reject(new n.AL)):new L(f.sort((R=r.snippetSortOrder,x.get(R))),C,{entries:v,elapsed:h.elapsed()},_);var R}function T(e,t){if(e.sortTextLow&&t.sortTextLow){if(e.sortTextLowt.sortTextLow)return 1}return e.textLabelt.textLabel?1:e.completion.kind-t.completion.kind}const x=new Map;function k(e,t){e.getContribution("editor.contrib.suggestController")?.triggerSuggest((new Set).add(t),void 0,!0)}x.set(0,(function(e,t){if(e.completion.kind!==t.completion.kind){if(27===e.completion.kind)return-1;if(27===t.completion.kind)return 1}return T(e,t)})),x.set(2,(function(e,t){if(e.completion.kind!==t.completion.kind){if(27===e.completion.kind)return 1;if(27===t.completion.kind)return-1}return T(e,t)})),x.set(1,T),f.w.registerCommand("_executeCompletionItemProvider",(async(e,...t)=>{const[i,n,r,o]=t;(0,l.j)(c.r.isUri(i)),(0,l.j)(h.y.isIPosition(n)),(0,l.j)("string"===typeof r||!r),(0,l.j)("number"===typeof o||!o);const{completionProvider:a}=e.get(v.ILanguageFeaturesService),d=await e.get(u.ITextModelService).createModelReference(i);try{const e={incomplete:!1,suggestions:[]},t=[],i=d.object.textEditorModel.validatePosition(n),l=await R(a,d.object.textEditorModel,i,void 0,{triggerCharacter:r??void 0,triggerKind:r?1:0});for(const n of l.items)t.length<(o??0)&&t.push(n.resolve(s.XO.None)),e.incomplete=e.incomplete||n.container.incomplete,e.suggestions.push(n.completion);try{return await Promise.all(t),e}finally{setTimeout((()=>l.disposable.dispose()),100)}}finally{d.dispose()}}));class A{static isAllOff(e){return"off"===e.other&&"off"===e.comments&&"off"===e.strings}static isAllOn(e){return"on"===e.other&&"on"===e.comments&&"on"===e.strings}static valueFor(e,t){switch(t){case 1:return e.comments;case 2:return e.strings;default:return e.other}}}},90870:(e,t,i)=>{"use strict";i.d(t,{D:()=>je});var s,n=i(11007),r=i(25890),o=i(18447),a=i(64383),l=i(41234),c=i(42539),h=i(5662),d=i(98067),u=i(78381),g=i(631),p=i(55190),m=i(31450),f=i(7085),_=i(83069),v=i(36677),C=i(60002),b=i(30936),E=i(29319),S=i(88415),y=i(32848),w=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},L=function(e,t){return function(i,s){t(i,s,e)}};let R=class{static{s=this}static{this.AtEnd=new y.N1("atEndOfWord",!1)}constructor(e,t){this._editor=e,this._enabled=!1,this._ckAtEnd=s.AtEnd.bindTo(t),this._configListener=this._editor.onDidChangeConfiguration((e=>e.hasChanged(124)&&this._update())),this._update()}dispose(){this._configListener.dispose(),this._selectionListener?.dispose(),this._ckAtEnd.reset()}_update(){const e="on"===this._editor.getOption(124);if(this._enabled!==e)if(this._enabled=e,this._enabled){const e=()=>{if(!this._editor.hasModel())return void this._ckAtEnd.set(!1);const e=this._editor.getModel(),t=this._editor.getSelection(),i=e.getWordAtPosition(t.getStartPosition());i?this._ckAtEnd.set(i.endColumn===t.getStartPosition().column):this._ckAtEnd.set(!1)};this._selectionListener=this._editor.onDidChangeCursorSelection(e),e()}else this._selectionListener&&(this._ckAtEnd.reset(),this._selectionListener.dispose(),this._selectionListener=void 0)}};R=s=w([L(1,y.fN)],R);var T,x=i(78209),k=i(50091),A=i(63591),N=i(18801),I=i(48116),O=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},D=function(e,t){return function(i,s){t(i,s,e)}};let M=class{static{T=this}static{this.OtherSuggestions=new y.N1("hasOtherSuggestions",!1)}constructor(e,t){this._editor=e,this._index=0,this._ckOtherSuggestions=T.OtherSuggestions.bindTo(t)}dispose(){this.reset()}reset(){this._ckOtherSuggestions.reset(),this._listener?.dispose(),this._model=void 0,this._acceptNext=void 0,this._ignore=!1}set({model:e,index:t},i){if(0===e.items.length)return void this.reset();T._moveIndex(!0,e,t)!==t?(this._acceptNext=i,this._model=e,this._index=t,this._listener=this._editor.onDidChangeCursorPosition((()=>{this._ignore||this.reset()})),this._ckOtherSuggestions.set(!0)):this.reset()}static _moveIndex(e,t,i){let s=i;for(let n=t.items.length;n>0&&(s=(s+t.items.length+(e?1:-1))%t.items.length,s!==i)&&t.items[s].completion.additionalTextEdits;n--);return s}next(){this._move(!0)}prev(){this._move(!1)}_move(e){if(this._model)try{this._ignore=!0,this._index=T._moveIndex(e,this._model,this._index),this._acceptNext({index:this._index,item:this._model.items[this._index],model:this._model})}finally{this._ignore=!1}}};M=T=O([D(1,y.fN)],M);var P=i(60534);class F{constructor(e,t,i,s){this._disposables=new h.Cm,this._disposables.add(i.onDidSuggest((e=>{0===e.completionModel.items.length&&this.reset()}))),this._disposables.add(i.onDidCancel((e=>{this.reset()}))),this._disposables.add(t.onDidShow((()=>this._onItem(t.getFocusedItem())))),this._disposables.add(t.onDidFocus(this._onItem,this)),this._disposables.add(t.onDidHide(this.reset,this)),this._disposables.add(e.onWillType((n=>{if(this._active&&!t.isFrozen()&&0!==i.state){const t=n.charCodeAt(n.length-1);this._active.acceptCharacters.has(t)&&e.getOption(0)&&s(this._active.item)}})))}_onItem(e){if(!e||!(0,r.EI)(e.item.completion.commitCharacters))return void this.reset();if(this._active&&this._active.item.item===e.item)return;const t=new P.y;for(const i of e.item.completion.commitCharacters)i.length>0&&t.add(i.charCodeAt(0));this._active={acceptCharacters:t,item:e}}reset(){this._active=void 0}dispose(){this._disposables.dispose()}}var U=i(96299);class H{static{this._maxSelectionLength=51200}constructor(e,t){this._disposables=new h.Cm,this._lastOvertyped=[],this._locked=!1,this._disposables.add(e.onWillType((()=>{if(this._locked||!e.hasModel())return;const t=e.getSelections(),i=t.length;let s=!1;for(let e=0;eH._maxSelectionLength)return;this._lastOvertyped[e]={value:n.getValueInRange(i),multiline:i.startLineNumber!==i.endLineNumber}}}))),this._disposables.add(t.onDidTrigger((e=>{this._locked=!0}))),this._disposables.add(t.onDidCancel((e=>{this._locked=!1})))}getLastOvertypedInfo(e){if(e>=0&&e=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Q=function(e,t){return function(i,s){t(i,s,e)}};let X=class{constructor(e,t,i,s,n){this._menuId=t,this._menuService=s,this._contextKeyService=n,this._menuDisposables=new h.Cm,this.element=B.BC(e,B.$(".suggest-status-bar"));const r=e=>e instanceof q.Xe?i.createInstance(Y.rr,e,{useComma:!0}):void 0;this._leftActions=new K.E(this.element,{actionViewItemProvider:r}),this._rightActions=new K.E(this.element,{actionViewItemProvider:r}),this._leftActions.domNode.classList.add("left"),this._rightActions.domNode.classList.add("right")}dispose(){this._menuDisposables.dispose(),this._leftActions.dispose(),this._rightActions.dispose(),this.element.remove()}show(){const e=this._menuService.createMenu(this._menuId,this._contextKeyService),t=()=>{const t=[],i=[];for(const[s,n]of e.getActions())"left"===s?t.push(...n):i.push(...n);this._leftActions.clear(),this._leftActions.push(t),this._rightActions.clear(),this._rightActions.push(i)};this._menuDisposables.add(e.onDidChange((()=>t()))),this._menuDisposables.add(e)}hide(){this._menuDisposables.clear()}};X=$([Q(2,A._Y),Q(3,q.ez),Q(4,y.fN)],X);i(93409);var Z=i(9711),J=i(66261),ee=i(86723),te=i(47612),ie=i(88807),se=i(31295),ne=i(10350),re=i(25689),oe=i(16980),ae=i(20492),le=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ce=function(e,t){return function(i,s){t(i,s,e)}};function he(e){return!!e&&Boolean(e.completion.documentation||e.completion.detail&&e.completion.detail!==e.completion.label)}let de=class{constructor(e,t){this._editor=e,this._onDidClose=new l.vl,this.onDidClose=this._onDidClose.event,this._onDidChangeContents=new l.vl,this.onDidChangeContents=this._onDidChangeContents.event,this._disposables=new h.Cm,this._renderDisposeable=new h.Cm,this._borderWidth=1,this._size=new B.fg(330,0),this.domNode=B.$(".suggest-details"),this.domNode.classList.add("no-docs"),this._markdownRenderer=t.createInstance(ae.T,{editor:e}),this._body=B.$(".body"),this._scrollbar=new se.MU(this._body,{alwaysConsumeMouseWheel:!0}),B.BC(this.domNode,this._scrollbar.getDomNode()),this._disposables.add(this._scrollbar),this._header=B.BC(this._body,B.$(".header")),this._close=B.BC(this._header,B.$("span"+re.L.asCSSSelector(ne.W.close))),this._close.title=x.kg("details.close","Close"),this._type=B.BC(this._header,B.$("p.type")),this._docs=B.BC(this._body,B.$("p.docs")),this._configureFont(),this._disposables.add(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(50)&&this._configureFont()})))}dispose(){this._disposables.dispose(),this._renderDisposeable.dispose()}_configureFont(){const e=this._editor.getOptions(),t=e.get(50),i=t.getMassagedFontFamily(),s=e.get(120)||t.fontSize,n=e.get(121)||t.lineHeight,r=t.fontWeight,o=`${s}px`,a=`${n}px`;this.domNode.style.fontSize=o,this.domNode.style.lineHeight=""+n/s,this.domNode.style.fontWeight=r,this.domNode.style.fontFeatureSettings=t.fontFeatureSettings,this._type.style.fontFamily=i,this._close.style.height=a,this._close.style.width=a}getLayoutInfo(){const e=this._editor.getOption(121)||this._editor.getOption(50).lineHeight,t=this._borderWidth;return{lineHeight:e,borderWidth:t,borderHeight:2*t,verticalPadding:22,horizontalPadding:14}}renderLoading(){this._type.textContent=x.kg("loading","Loading..."),this._docs.textContent="",this.domNode.classList.remove("no-docs","no-type"),this.layout(this.size.width,2*this.getLayoutInfo().lineHeight),this._onDidChangeContents.fire(this)}renderItem(e,t){this._renderDisposeable.clear();let{detail:i,documentation:s}=e.completion;if(t){let t="";t+=`score: ${e.score[0]}\n`,t+=`prefix: ${e.word??"(no prefix)"}\n`,t+=`word: ${e.completion.filterText?e.completion.filterText+" (filterText)":e.textLabel}\n`,t+=`distance: ${e.distance} (localityBonus-setting)\n`,t+=`index: ${e.idx}, based on ${e.completion.sortText&&`sortText: "${e.completion.sortText}"`||"label"}\n`,t+=`commit_chars: ${e.completion.commitCharacters?.join("")}\n`,s=(new oe.Bc).appendCodeblock("empty",t),i=`Provider: ${e.provider._debugDisplayName}`}if(t||he(e)){if(this.domNode.classList.remove("no-docs","no-type"),i){const e=i.length>1e5?`${i.substr(0,1e5)}\u2026`:i;this._type.textContent=e,this._type.title=e,B.WU(this._type),this._type.classList.toggle("auto-wrap",!/\r?\n^\s+/gim.test(e))}else B.w_(this._type),this._type.title="",B.jD(this._type),this.domNode.classList.add("no-type");if(B.w_(this._docs),"string"===typeof s)this._docs.classList.remove("markdown-docs"),this._docs.textContent=s;else if(s){this._docs.classList.add("markdown-docs"),B.w_(this._docs);const e=this._markdownRenderer.render(s);this._docs.appendChild(e.element),this._renderDisposeable.add(e),this._renderDisposeable.add(this._markdownRenderer.onDidRenderAsync((()=>{this.layout(this._size.width,this._type.clientHeight+this._docs.clientHeight),this._onDidChangeContents.fire(this)})))}this.domNode.style.userSelect="text",this.domNode.tabIndex=-1,this._close.onmousedown=e=>{e.preventDefault(),e.stopPropagation()},this._close.onclick=e=>{e.preventDefault(),e.stopPropagation(),this._onDidClose.fire()},this._body.scrollTop=0,this.layout(this._size.width,this._type.clientHeight+this._docs.clientHeight),this._onDidChangeContents.fire(this)}else this.clearContents()}clearContents(){this.domNode.classList.add("no-docs"),this._type.textContent="",this._docs.textContent=""}get isEmpty(){return this.domNode.classList.contains("no-docs")}get size(){return this._size}layout(e,t){const i=new B.fg(e,t);B.fg.equals(i,this._size)||(this._size=i,B.Ej(this.domNode,e,t)),this._scrollbar.scanDomNode()}scrollDown(e=8){this._body.scrollTop+=e}scrollUp(e=8){this._body.scrollTop-=e}scrollTop(){this._body.scrollTop=0}scrollBottom(){this._body.scrollTop=this._body.scrollHeight}pageDown(){this.scrollDown(80)}pageUp(){this.scrollUp(80)}set borderWidth(e){this._borderWidth=e}get borderWidth(){return this._borderWidth}};de=le([ce(1,A._Y)],de);class ue{constructor(e,t){let i,s;this.widget=e,this._editor=t,this.allowEditorOverflow=!0,this._disposables=new h.Cm,this._added=!1,this._preferAlignAtTop=!0,this._resizable=new ie.v,this._resizable.domNode.classList.add("suggest-details-container"),this._resizable.domNode.appendChild(e.domNode),this._resizable.enableSashes(!1,!0,!0,!1);let n=0,r=0;this._disposables.add(this._resizable.onDidWillResize((()=>{i=this._topLeft,s=this._resizable.size}))),this._disposables.add(this._resizable.onDidResize((e=>{if(i&&s){this.widget.layout(e.dimension.width,e.dimension.height);let t=!1;e.west&&(r=s.width-e.dimension.width,t=!0),e.north&&(n=s.height-e.dimension.height,t=!0),t&&this._applyTopLeft({top:i.top+n,left:i.left+r})}e.done&&(i=void 0,s=void 0,n=0,r=0,this._userSize=e.dimension)}))),this._disposables.add(this.widget.onDidChangeContents((()=>{this._anchorBox&&this._placeAtAnchor(this._anchorBox,this._userSize??this.widget.size,this._preferAlignAtTop)})))}dispose(){this._resizable.dispose(),this._disposables.dispose(),this.hide()}getId(){return"suggest.details"}getDomNode(){return this._resizable.domNode}getPosition(){return this._topLeft?{preference:this._topLeft}:null}show(){this._added||(this._editor.addOverlayWidget(this),this._added=!0)}hide(e=!1){this._resizable.clearSashHoverState(),this._added&&(this._editor.removeOverlayWidget(this),this._added=!1,this._anchorBox=void 0,this._topLeft=void 0),e&&(this._userSize=void 0,this.widget.clearContents())}placeAtAnchor(e,t){const i=e.getBoundingClientRect();this._anchorBox=i,this._preferAlignAtTop=t,this._placeAtAnchor(this._anchorBox,this._userSize??this.widget.size,t)}_placeAtAnchor(e,t,i){const s=B.tG(this.getDomNode().ownerDocument.body),n=this.widget.getLayoutInfo(),r=new B.fg(220,2*n.lineHeight),o=e.top,a=function(){const i=s.width-(e.left+e.width+n.borderWidth+n.horizontalPadding),a=-n.borderWidth+e.left+e.width,l=new B.fg(i,s.height-e.top-n.borderHeight-n.verticalPadding),c=l.with(void 0,e.top+e.height-n.borderHeight-n.verticalPadding);return{top:o,left:a,fit:i-t.width,maxSizeTop:l,maxSizeBottom:c,minSize:r.with(Math.min(i,r.width))}}(),l=function(){const i=e.left-n.borderWidth-n.horizontalPadding,a=Math.max(n.horizontalPadding,e.left-t.width-n.borderWidth),l=new B.fg(i,s.height-e.top-n.borderHeight-n.verticalPadding),c=l.with(void 0,e.top+e.height-n.borderHeight-n.verticalPadding);return{top:o,left:a,fit:i-t.width,maxSizeTop:l,maxSizeBottom:c,minSize:r.with(Math.min(i,r.width))}}(),c=function(){const i=e.left,o=-n.borderWidth+e.top+e.height,a=new B.fg(e.width-n.borderHeight,s.height-e.top-e.height-n.verticalPadding);return{top:o,left:i,fit:a.height-t.height,maxSizeBottom:a,maxSizeTop:a,minSize:r.with(a.width)}}(),h=[a,l,c],d=h.find((e=>e.fit>=0))??h.sort(((e,t)=>t.fit-e.fit))[0],u=e.top+e.height-n.borderHeight;let g,p=t.height;const m=Math.max(d.maxSizeTop.height,d.maxSizeBottom.height);let f;p>m&&(p=m),i?p<=d.maxSizeTop.height?(g=!0,f=d.maxSizeTop):(g=!1,f=d.maxSizeBottom):p<=d.maxSizeBottom.height?(g=!1,f=d.maxSizeBottom):(g=!0,f=d.maxSizeTop);let{top:_,left:v}=d;!g&&p>e.height&&(_=u-p);const C=this._editor.getDomNode();if(C){const e=C.getBoundingClientRect();_-=e.top,v-=e.left}this._applyTopLeft({left:v,top:_}),this._resizable.enableSashes(!g,d===a,g,d!==a),this._resizable.minSize=d.minSize,this._resizable.maxSize=f,this._resizable.layout(p,Math.min(f.width,t.width)),this.widget.layout(this._resizable.size.width,this._resizable.size.height)}_applyTopLeft(e){this._topLeft=e,this._editor.layoutOverlayWidget(this)}}var ge=i(21852),pe=i(26690),me=i(79400),fe=i(62083),_e=i(53068),ve=i(23750),Ce=i(10154),be=i(7291),Ee=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Se=function(e,t){return function(i,s){t(i,s,e)}};function ye(e){return`suggest-aria-id:${e}`}const we=(0,i(61394).pU)("suggest-more-info",ne.W.chevronRight,x.kg("suggestMoreInfoIcon","Icon for more information in the suggest widget.")),Le=new class e{static{this._regexRelaxed=/(#([\da-fA-F]{3}){1,2}|(rgb|hsl)a\(\s*(\d{1,3}%?\s*,\s*){3}(1|0?\.\d+)\)|(rgb|hsl)\(\s*\d{1,3}%?(\s*,\s*\d{1,3}%?){2}\s*\))/}static{this._regexStrict=new RegExp(`^${e._regexRelaxed.source}$`,"i")}extract(t,i){if(t.textLabel.match(e._regexStrict))return i[0]=t.textLabel,!0;if(t.completion.detail&&t.completion.detail.match(e._regexStrict))return i[0]=t.completion.detail,!0;if(t.completion.documentation){const s="string"===typeof t.completion.documentation?t.completion.documentation:t.completion.documentation.value,n=e._regexRelaxed.exec(s);if(n&&(0===n.index||n.index+n[0].length===s.length))return i[0]=n[0],!0}return!1}};let Re=class{constructor(e,t,i,s){this._editor=e,this._modelService=t,this._languageService=i,this._themeService=s,this._onDidToggleDetails=new l.vl,this.onDidToggleDetails=this._onDidToggleDetails.event,this.templateId="suggestion"}dispose(){this._onDidToggleDetails.dispose()}renderTemplate(e){const t=new h.Cm,i=e;i.classList.add("show-file-icons");const s=(0,B.BC)(e,(0,B.$)(".icon")),n=(0,B.BC)(s,(0,B.$)("span.colorspan")),r=(0,B.BC)(e,(0,B.$)(".contents")),o=(0,B.BC)(r,(0,B.$)(".main")),a=(0,B.BC)(o,(0,B.$)(".icon-label.codicon")),l=(0,B.BC)(o,(0,B.$)("span.left")),c=(0,B.BC)(o,(0,B.$)("span.right")),d=new ge.s(l,{supportHighlights:!0,supportIcons:!0});t.add(d);const u=(0,B.BC)(l,(0,B.$)("span.signature-label")),g=(0,B.BC)(l,(0,B.$)("span.qualifier-label")),p=(0,B.BC)(c,(0,B.$)("span.details-label")),m=(0,B.BC)(c,(0,B.$)("span.readMore"+re.L.asCSSSelector(we)));m.title=x.kg("readMore","Read More");return{root:i,left:l,right:c,icon:s,colorspan:n,iconLabel:d,iconContainer:a,parametersLabel:u,qualifierLabel:g,detailsLabel:p,readMore:m,disposables:t,configureFont:()=>{const e=this._editor.getOptions(),t=e.get(50),n=t.getMassagedFontFamily(),r=t.fontFeatureSettings,a=e.get(120)||t.fontSize,l=e.get(121)||t.lineHeight,c=t.fontWeight,h=`${a}px`,d=`${l}px`,u=`${t.letterSpacing}px`;i.style.fontSize=h,i.style.fontWeight=c,i.style.letterSpacing=u,o.style.fontFamily=n,o.style.fontFeatureSettings=r,o.style.lineHeight=d,s.style.height=d,s.style.width=d,m.style.height=d,m.style.width=d}}}renderElement(e,t,i){i.configureFont();const{completion:s}=e;i.root.id=ye(t),i.colorspan.style.backgroundColor="";const n={labelEscapeNewLines:!0,matches:(0,pe.WJ)(e.score)},r=[];if(19===s.kind&&Le.extract(e,r))i.icon.className="icon customcolor",i.iconContainer.className="icon hide",i.colorspan.style.backgroundColor=r[0];else if(20===s.kind&&this._themeService.getFileIconTheme().hasFileIcons){i.icon.className="icon hide",i.iconContainer.className="icon hide";const t=(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:e.textLabel}),be.p.FILE),r=(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:s.detail}),be.p.FILE);n.extraClasses=t.length>r.length?t:r}else 23===s.kind&&this._themeService.getFileIconTheme().hasFolderIcons?(i.icon.className="icon hide",i.iconContainer.className="icon hide",n.extraClasses=[(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:e.textLabel}),be.p.FOLDER),(0,_e.getIconClasses)(this._modelService,this._languageService,me.r.from({scheme:"fake",path:s.detail}),be.p.FOLDER)].flat()):(i.icon.className="icon hide",i.iconContainer.className="",i.iconContainer.classList.add("suggest-icon",...re.L.asClassNameArray(fe.HC.toIcon(s.kind))));s.tags&&s.tags.indexOf(1)>=0&&(n.extraClasses=(n.extraClasses||[]).concat(["deprecated"]),n.matches=[]),i.iconLabel.setLabel(e.textLabel,void 0,n),"string"===typeof s.label?(i.parametersLabel.textContent="",i.detailsLabel.textContent=Te(s.detail||""),i.root.classList.add("string-label")):(i.parametersLabel.textContent=Te(s.label.detail||""),i.detailsLabel.textContent=Te(s.label.description||""),i.root.classList.remove("string-label")),this._editor.getOption(119).showInlineDetails?(0,B.WU)(i.detailsLabel):(0,B.jD)(i.detailsLabel),he(e)?(i.right.classList.add("can-expand-details"),(0,B.WU)(i.readMore),i.readMore.onmousedown=e=>{e.stopPropagation(),e.preventDefault()},i.readMore.onclick=e=>{e.stopPropagation(),e.preventDefault(),this._onDidToggleDetails.fire()}):(i.right.classList.remove("can-expand-details"),(0,B.jD)(i.readMore),i.readMore.onmousedown=null,i.readMore.onclick=null)}disposeTemplate(e){e.disposables.dispose()}};function Te(e){return e.replace(/\r\n|\r|\n/g,"")}Re=Ee([Se(1,ve.IModelService),Se(2,Ce.L),Se(3,te.Gy)],Re);var xe,ke=i(19070),Ae=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},Ne=function(e,t){return function(i,s){t(i,s,e)}};(0,J.x1A)("editorSuggestWidget.background",J.CgL,x.kg("editorSuggestWidgetBackground","Background color of the suggest widget.")),(0,J.x1A)("editorSuggestWidget.border",J.sIe,x.kg("editorSuggestWidgetBorder","Border color of the suggest widget."));const Ie=(0,J.x1A)("editorSuggestWidget.foreground",J.By2,x.kg("editorSuggestWidgetForeground","Foreground color of the suggest widget."));(0,J.x1A)("editorSuggestWidget.selectedForeground",J.nH,x.kg("editorSuggestWidgetSelectedForeground","Foreground color of the selected entry in the suggest widget.")),(0,J.x1A)("editorSuggestWidget.selectedIconForeground",J.c7i,x.kg("editorSuggestWidgetSelectedIconForeground","Icon foreground color of the selected entry in the suggest widget."));const Oe=(0,J.x1A)("editorSuggestWidget.selectedBackground",J.AlL,x.kg("editorSuggestWidgetSelectedBackground","Background color of the selected entry in the suggest widget."));(0,J.x1A)("editorSuggestWidget.highlightForeground",J.QI5,x.kg("editorSuggestWidgetHighlightForeground","Color of the match highlights in the suggest widget.")),(0,J.x1A)("editorSuggestWidget.focusHighlightForeground",J.eMz,x.kg("editorSuggestWidgetFocusHighlightForeground","Color of the match highlights in the suggest widget when an item is focused.")),(0,J.x1A)("editorSuggestWidgetStatus.foreground",(0,J.JO0)(Ie,.5),x.kg("editorSuggestWidgetStatusForeground","Foreground color of the suggest widget status."));class De{constructor(e,t){this._service=e,this._key=`suggestWidget.size/${t.getEditorType()}/${t instanceof j.t}`}restore(){const e=this._service.get(this._key,0)??"";try{const t=JSON.parse(e);if(B.fg.is(t))return B.fg.lift(t)}catch{}}store(e){this._service.store(this._key,JSON.stringify(e),0,1)}reset(){this._service.remove(this._key,0)}}let Me=class{static{xe=this}static{this.LOADING_MESSAGE=x.kg("suggestWidget.loading","Loading...")}static{this.NO_SUGGESTIONS_MESSAGE=x.kg("suggestWidget.noSuggestions","No suggestions.")}constructor(e,t,i,s,n){this.editor=e,this._storageService=t,this._state=0,this._isAuto=!1,this._pendingLayout=new h.HE,this._pendingShowDetails=new h.HE,this._ignoreFocusEvents=!1,this._forceRenderingAbove=!1,this._explainMode=!1,this._showTimeout=new V.pc,this._disposables=new h.Cm,this._onDidSelect=new l.fV,this._onDidFocus=new l.fV,this._onDidHide=new l.vl,this._onDidShow=new l.vl,this.onDidSelect=this._onDidSelect.event,this.onDidFocus=this._onDidFocus.event,this.onDidHide=this._onDidHide.event,this.onDidShow=this._onDidShow.event,this._onDetailsKeydown=new l.vl,this.onDetailsKeyDown=this._onDetailsKeydown.event,this.element=new ie.v,this.element.domNode.classList.add("editor-widget","suggest-widget"),this._contentWidget=new Pe(this,e),this._persistedSize=new De(t,e);class r{constructor(e,t,i=!1,s=!1){this.persistedSize=e,this.currentSize=t,this.persistHeight=i,this.persistWidth=s}}let o;this._disposables.add(this.element.onDidWillResize((()=>{this._contentWidget.lockPreference(),o=new r(this._persistedSize.restore(),this.element.size)}))),this._disposables.add(this.element.onDidResize((e=>{if(this._resize(e.dimension.width,e.dimension.height),o&&(o.persistHeight=o.persistHeight||!!e.north||!!e.south,o.persistWidth=o.persistWidth||!!e.east||!!e.west),e.done){if(o){const{itemHeight:e,defaultSize:t}=this.getLayoutInfo(),i=Math.round(e/2);let{width:s,height:n}=this.element.size;(!o.persistHeight||Math.abs(o.currentSize.height-n)<=i)&&(n=o.persistedSize?.height??t.height),(!o.persistWidth||Math.abs(o.currentSize.width-s)<=i)&&(s=o.persistedSize?.width??t.width),this._persistedSize.store(new B.fg(s,n))}this._contentWidget.unlockPreference(),o=void 0}}))),this._messageElement=B.BC(this.element.domNode,B.$(".message")),this._listElement=B.BC(this.element.domNode,B.$(".tree"));const a=this._disposables.add(n.createInstance(de,this.editor));a.onDidClose(this.toggleDetails,this,this._disposables),this._details=new ue(a,this.editor);const c=()=>this.element.domNode.classList.toggle("no-icons",!this.editor.getOption(119).showIcons);c();const d=n.createInstance(Re,this.editor);this._disposables.add(d),this._disposables.add(d.onDidToggleDetails((()=>this.toggleDetails()))),this._list=new W.B8("SuggestWidget",this._listElement,{getHeight:e=>this.getLayoutInfo().itemHeight,getTemplateId:e=>"suggestion"},[d],{alwaysConsumeMouseWheel:!0,useShadows:!1,mouseSupport:!1,multipleSelectionSupport:!1,accessibilityProvider:{getRole:()=>"option",getWidgetAriaLabel:()=>x.kg("suggest","Suggest"),getWidgetRole:()=>"listbox",getAriaLabel:e=>{let t=e.textLabel;if("string"!==typeof e.completion.label){const{detail:i,description:s}=e.completion.label;i&&s?t=x.kg("label.full","{0} {1}, {2}",t,i,s):i?t=x.kg("label.detail","{0} {1}",t,i):s&&(t=x.kg("label.desc","{0}, {1}",t,s))}if(!e.isResolved||!this._isDetailsVisible())return t;const{documentation:i,detail:s}=e.completion,n=G.GP("{0}{1}",s||"",i?"string"===typeof i?i:i.value:"");return x.kg("ariaCurrenttSuggestionReadDetails","{0}, docs: {1}",t,n)}}}),this._list.style((0,ke.t8)({listInactiveFocusBackground:Oe,listInactiveFocusOutline:J.buw})),this._status=n.createInstance(X,this.element.domNode,I.dt);const u=()=>this.element.domNode.classList.toggle("with-status-bar",this.editor.getOption(119).showStatusBar);u(),this._disposables.add(s.onDidColorThemeChange((e=>this._onThemeChange(e)))),this._onThemeChange(s.getColorTheme()),this._disposables.add(this._list.onMouseDown((e=>this._onListMouseDownOrTap(e)))),this._disposables.add(this._list.onTap((e=>this._onListMouseDownOrTap(e)))),this._disposables.add(this._list.onDidChangeSelection((e=>this._onListSelection(e)))),this._disposables.add(this._list.onDidChangeFocus((e=>this._onListFocus(e)))),this._disposables.add(this.editor.onDidChangeCursorSelection((()=>this._onCursorSelectionChanged()))),this._disposables.add(this.editor.onDidChangeConfiguration((e=>{e.hasChanged(119)&&(u(),c()),this._completionModel&&(e.hasChanged(50)||e.hasChanged(120)||e.hasChanged(121))&&this._list.splice(0,this._list.length,this._completionModel.items)}))),this._ctxSuggestWidgetVisible=I.ob.Visible.bindTo(i),this._ctxSuggestWidgetDetailsVisible=I.ob.DetailsVisible.bindTo(i),this._ctxSuggestWidgetMultipleSuggestions=I.ob.MultipleSuggestions.bindTo(i),this._ctxSuggestWidgetHasFocusedSuggestion=I.ob.HasFocusedSuggestion.bindTo(i),this._disposables.add(B.b2(this._details.widget.domNode,"keydown",(e=>{this._onDetailsKeydown.fire(e)}))),this._disposables.add(this.editor.onMouseDown((e=>this._onEditorMouseDown(e))))}dispose(){this._details.widget.dispose(),this._details.dispose(),this._list.dispose(),this._status.dispose(),this._disposables.dispose(),this._loadingTimeout?.dispose(),this._pendingLayout.dispose(),this._pendingShowDetails.dispose(),this._showTimeout.dispose(),this._contentWidget.dispose(),this.element.dispose()}_onEditorMouseDown(e){this._details.widget.domNode.contains(e.target.element)?this._details.widget.domNode.focus():this.element.domNode.contains(e.target.element)&&this.editor.focus()}_onCursorSelectionChanged(){0!==this._state&&this._contentWidget.layout()}_onListMouseDownOrTap(e){"undefined"!==typeof e.element&&"undefined"!==typeof e.index&&(e.browserEvent.preventDefault(),e.browserEvent.stopPropagation(),this._select(e.element,e.index))}_onListSelection(e){e.elements.length&&this._select(e.elements[0],e.indexes[0])}_select(e,t){const i=this._completionModel;i&&(this._onDidSelect.fire({item:e,index:t,model:i}),this.editor.focus())}_onThemeChange(e){this._details.widget.borderWidth=(0,ee.Bb)(e.type)?2:1}_onListFocus(e){if(this._ignoreFocusEvents)return;if(!e.elements.length)return this._currentSuggestionDetails&&(this._currentSuggestionDetails.cancel(),this._currentSuggestionDetails=void 0,this._focusedItem=void 0),this.editor.setAriaOptions({activeDescendant:void 0}),void this._ctxSuggestWidgetHasFocusedSuggestion.set(!1);if(!this._completionModel)return;this._ctxSuggestWidgetHasFocusedSuggestion.set(!0);const t=e.elements[0],i=e.indexes[0];t!==this._focusedItem&&(this._currentSuggestionDetails?.cancel(),this._currentSuggestionDetails=void 0,this._focusedItem=t,this._list.reveal(i),this._currentSuggestionDetails=(0,V.SS)((async e=>{const i=(0,V.EQ)((()=>{this._isDetailsVisible()&&this.showDetails(!0)}),250),s=e.onCancellationRequested((()=>i.dispose()));try{return await t.resolve(e)}finally{i.dispose(),s.dispose()}})),this._currentSuggestionDetails.then((()=>{i>=this._list.length||t!==this._list.element(i)||(this._ignoreFocusEvents=!0,this._list.splice(i,1,[t]),this._list.setFocus([i]),this._ignoreFocusEvents=!1,this._isDetailsVisible()?this.showDetails(!1):this.element.domNode.classList.remove("docs-side"),this.editor.setAriaOptions({activeDescendant:ye(i)}))})).catch(a.dz)),this._onDidFocus.fire({item:t,index:i,model:this._completionModel})}_setState(e){if(this._state!==e)switch(this._state=e,this.element.domNode.classList.toggle("frozen",4===e),this.element.domNode.classList.remove("message"),e){case 0:B.jD(this._messageElement,this._listElement,this._status.element),this._details.hide(!0),this._status.hide(),this._contentWidget.hide(),this._ctxSuggestWidgetVisible.reset(),this._ctxSuggestWidgetMultipleSuggestions.reset(),this._ctxSuggestWidgetHasFocusedSuggestion.reset(),this._showTimeout.cancel(),this.element.domNode.classList.remove("visible"),this._list.splice(0,this._list.length),this._focusedItem=void 0,this._cappedHeight=void 0,this._explainMode=!1;break;case 1:this.element.domNode.classList.add("message"),this._messageElement.textContent=xe.LOADING_MESSAGE,B.jD(this._listElement,this._status.element),B.WU(this._messageElement),this._details.hide(),this._show(),this._focusedItem=void 0,(0,n.h5)(xe.LOADING_MESSAGE);break;case 2:this.element.domNode.classList.add("message"),this._messageElement.textContent=xe.NO_SUGGESTIONS_MESSAGE,B.jD(this._listElement,this._status.element),B.WU(this._messageElement),this._details.hide(),this._show(),this._focusedItem=void 0,(0,n.h5)(xe.NO_SUGGESTIONS_MESSAGE);break;case 3:case 4:B.jD(this._messageElement),B.WU(this._listElement,this._status.element),this._show();break;case 5:B.jD(this._messageElement),B.WU(this._listElement,this._status.element),this._details.show(),this._show()}}_show(){this._status.show(),this._contentWidget.show(),this._layout(this._persistedSize.restore()),this._ctxSuggestWidgetVisible.set(!0),this._showTimeout.cancelAndSet((()=>{this.element.domNode.classList.add("visible"),this._onDidShow.fire(this)}),100)}showTriggered(e,t){0===this._state&&(this._contentWidget.setPosition(this.editor.getPosition()),this._isAuto=!!e,this._isAuto||(this._loadingTimeout=(0,V.EQ)((()=>this._setState(1)),t)))}showSuggestions(e,t,i,s,n){if(this._contentWidget.setPosition(this.editor.getPosition()),this._loadingTimeout?.dispose(),this._currentSuggestionDetails?.cancel(),this._currentSuggestionDetails=void 0,this._completionModel!==e&&(this._completionModel=e),i&&2!==this._state&&0!==this._state)return void this._setState(4);const r=this._completionModel.items.length,o=0===r;if(this._ctxSuggestWidgetMultipleSuggestions.set(r>1),o)return this._setState(s?0:2),void(this._completionModel=void 0);this._focusedItem=void 0,this._onDidFocus.pause(),this._onDidSelect.pause();try{this._list.splice(0,this._list.length,this._completionModel.items),this._setState(i?4:3),this._list.reveal(t,0),this._list.setFocus(n?[]:[t])}finally{this._onDidFocus.resume(),this._onDidSelect.resume()}this._pendingLayout.value=B.Oq(B.zk(this.element.domNode),(()=>{this._pendingLayout.clear(),this._layout(this.element.size),this._details.widget.domNode.classList.remove("focused")}))}focusSelected(){this._list.length>0&&this._list.setFocus([0])}selectNextPage(){switch(this._state){case 0:return!1;case 5:return this._details.widget.pageDown(),!0;case 1:return!this._isAuto;default:return this._list.focusNextPage(),!0}}selectNext(){switch(this._state){case 0:return!1;case 1:return!this._isAuto;default:return this._list.focusNext(1,!0),!0}}selectLast(){switch(this._state){case 0:return!1;case 5:return this._details.widget.scrollBottom(),!0;case 1:return!this._isAuto;default:return this._list.focusLast(),!0}}selectPreviousPage(){switch(this._state){case 0:return!1;case 5:return this._details.widget.pageUp(),!0;case 1:return!this._isAuto;default:return this._list.focusPreviousPage(),!0}}selectPrevious(){switch(this._state){case 0:return!1;case 1:return!this._isAuto;default:return this._list.focusPrevious(1,!0),!1}}selectFirst(){switch(this._state){case 0:return!1;case 5:return this._details.widget.scrollTop(),!0;case 1:return!this._isAuto;default:return this._list.focusFirst(),!0}}getFocusedItem(){if(0!==this._state&&2!==this._state&&1!==this._state&&this._completionModel&&this._list.getFocus().length>0)return{item:this._list.getFocusedElements()[0],index:this._list.getFocus()[0],model:this._completionModel}}toggleDetailsFocus(){5===this._state?(this._setState(3),this._details.widget.domNode.classList.remove("focused")):3===this._state&&this._isDetailsVisible()&&(this._setState(5),this._details.widget.domNode.classList.add("focused"))}toggleDetails(){this._isDetailsVisible()?(this._pendingShowDetails.clear(),this._ctxSuggestWidgetDetailsVisible.set(!1),this._setDetailsVisible(!1),this._details.hide(),this.element.domNode.classList.remove("shows-details")):!he(this._list.getFocusedElements()[0])&&!this._explainMode||3!==this._state&&5!==this._state&&4!==this._state||(this._ctxSuggestWidgetDetailsVisible.set(!0),this._setDetailsVisible(!0),this.showDetails(!1))}showDetails(e){this._pendingShowDetails.value=B.Oq(B.zk(this.element.domNode),(()=>{this._pendingShowDetails.clear(),this._details.show(),e?this._details.widget.renderLoading():this._details.widget.renderItem(this._list.getFocusedElements()[0],this._explainMode),this._details.widget.isEmpty?this._details.hide():(this._positionDetails(),this.element.domNode.classList.add("shows-details")),this.editor.focus()}))}toggleExplainMode(){this._list.getFocusedElements()[0]&&(this._explainMode=!this._explainMode,this._isDetailsVisible()?this.showDetails(!1):this.toggleDetails())}resetPersistedSize(){this._persistedSize.reset()}hideWidget(){this._pendingLayout.clear(),this._pendingShowDetails.clear(),this._loadingTimeout?.dispose(),this._setState(0),this._onDidHide.fire(this),this.element.clearSashHoverState();const e=this._persistedSize.restore(),t=Math.ceil(4.3*this.getLayoutInfo().itemHeight);e&&e.heightr&&(n=r);const o=this._completionModel?this._completionModel.stats.pLabelLen*i.typicalHalfwidthCharacterWidth:n,a=i.statusBarHeight+this._list.contentHeight+i.borderHeight,l=i.itemHeight+i.statusBarHeight,c=B.BK(this.editor.getDomNode()),h=this.editor.getScrolledVisiblePosition(this.editor.getPosition()),d=c.top+h.top+h.height,u=Math.min(t.height-d-i.verticalPadding,a),g=c.top+h.top-i.verticalPadding,p=Math.min(g,a);let m=Math.min(Math.max(p,u)+i.borderHeight,a);s===this._cappedHeight?.capped&&(s=this._cappedHeight.wanted),sm&&(s=m);const f=150;s>u||this._forceRenderingAbove&&g>f?(this._contentWidget.setPreference(1),this.element.enableSashes(!0,!0,!1,!1),m=p):(this._contentWidget.setPreference(2),this.element.enableSashes(!1,!0,!0,!1),m=u),this.element.preferredSize=new B.fg(o,i.defaultSize.height),this.element.maxSize=new B.fg(r,m),this.element.minSize=new B.fg(220,l),this._cappedHeight=s===a?{wanted:this._cappedHeight?.wanted??e.height,capped:s}:void 0}this._resize(n,s)}_resize(e,t){const{width:i,height:s}=this.element.maxSize;e=Math.min(i,e),t=Math.min(s,t);const{statusBarHeight:n}=this.getLayoutInfo();this._list.layout(t-n,e),this._listElement.style.height=t-n+"px",this.element.layout(t,e),this._contentWidget.layout(),this._positionDetails()}_positionDetails(){this._isDetailsVisible()&&this._details.placeAtAnchor(this.element.domNode,2===this._contentWidget.getPosition()?.preference[0])}getLayoutInfo(){const e=this.editor.getOption(50),t=(0,z.qE)(this.editor.getOption(121)||e.lineHeight,8,1e3),i=this.editor.getOption(119).showStatusBar&&2!==this._state&&1!==this._state?t:0,s=this._details.widget.borderWidth,n=2*s;return{itemHeight:t,statusBarHeight:i,borderWidth:s,borderHeight:n,typicalHalfwidthCharacterWidth:e.typicalHalfwidthCharacterWidth,verticalPadding:22,horizontalPadding:14,defaultSize:new B.fg(430,i+12*t+n)}}_isDetailsVisible(){return this._storageService.getBoolean("expandSuggestionDocs",0,!1)}_setDetailsVisible(e){this._storageService.store("expandSuggestionDocs",e,0,0)}forceRenderingAbove(){this._forceRenderingAbove||(this._forceRenderingAbove=!0,this._layout(this._persistedSize.restore()))}stopForceRenderingAbove(){this._forceRenderingAbove=!1}};Me=xe=Ae([Ne(1,Z.CS),Ne(2,y.fN),Ne(3,te.Gy),Ne(4,A._Y)],Me);class Pe{constructor(e,t){this._widget=e,this._editor=t,this.allowEditorOverflow=!0,this.suppressMouseDown=!1,this._preferenceLocked=!1,this._added=!1,this._hidden=!1}dispose(){this._added&&(this._added=!1,this._editor.removeContentWidget(this))}getId(){return"editor.widget.suggestWidget"}getDomNode(){return this._widget.element.domNode}show(){this._hidden=!1,this._added||(this._added=!0,this._editor.addContentWidget(this))}hide(){this._hidden||(this._hidden=!0,this.layout())}layout(){this._editor.layoutContentWidget(this)}getPosition(){return!this._hidden&&this._position&&this._preference?{position:this._position,preference:[this._preference]}:null}beforeRender(){const{height:e,width:t}=this._widget.element.size,{borderWidth:i,horizontalPadding:s}=this._widget.getLayoutInfo();return new B.fg(t+2*i+s,e+2*i)}afterRender(e){this._widget._afterRender(e)}setPreference(e){this._preferenceLocked||(this._preference=e)}lockPreference(){this._preferenceLocked=!0}unlockPreference(){this._preferenceLocked=!1}setPosition(e){this._position=e}}var Fe,Ue=i(90651),He=i(89403),Be=i(85600),We=i(87289),Ve=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ze=function(e,t){return function(i,s){t(i,s,e)}};class Ge{constructor(e,t){this._model=e,this._position=t,this._decorationOptions=We.kI.register({description:"suggest-line-suffix",stickiness:1});if(e.getLineMaxColumn(t.lineNumber)!==t.column){const i=e.getOffsetAt(t),s=e.getPositionAt(i+1);e.changeDecorations((e=>{this._marker&&e.removeDecoration(this._marker),this._marker=e.addDecoration(v.Q.fromPositions(t,s),this._decorationOptions)}))}}dispose(){this._marker&&!this._model.isDisposed()&&this._model.changeDecorations((e=>{e.removeDecoration(this._marker),this._marker=void 0}))}delta(e){if(this._model.isDisposed()||this._position.lineNumber!==e.lineNumber)return 0;if(this._marker){const t=this._model.getDecorationRange(this._marker);return this._model.getOffsetAt(t.getStartPosition())-this._model.getOffsetAt(e)}return this._model.getLineMaxColumn(e.lineNumber)-e.column}}let je=class{static{Fe=this}static{this.ID="editor.contrib.suggestController"}static get(e){return e.getContribution(Fe.ID)}constructor(e,t,i,s,n,r,o){this._memoryService=t,this._commandService=i,this._contextKeyService=s,this._instantiationService=n,this._logService=r,this._telemetryService=o,this._lineSuffix=new h.HE,this._toDispose=new h.Cm,this._selectors=new Ke((e=>e.priority)),this._onWillInsertSuggestItem=new l.vl,this.onWillInsertSuggestItem=this._onWillInsertSuggestItem.event,this.editor=e,this.model=n.createInstance(U.Y,this.editor),this._selectors.register({priority:0,select:(e,t,i)=>this._memoryService.select(e,t,i)});const a=I.ob.InsertMode.bindTo(s);a.set(e.getOption(119).insertMode),this._toDispose.add(this.model.onDidTrigger((()=>a.set(e.getOption(119).insertMode)))),this.widget=this._toDispose.add(new B.Ij((0,B.zk)(e.getDomNode()),(()=>{const e=this._instantiationService.createInstance(Me,this.editor);this._toDispose.add(e),this._toDispose.add(e.onDidSelect((e=>this._insertSuggestion(e,0)),this));const t=new F(this.editor,e,this.model,(e=>this._insertSuggestion(e,2)));this._toDispose.add(t);const i=I.ob.MakesTextEdit.bindTo(this._contextKeyService),s=I.ob.HasInsertAndReplaceRange.bindTo(this._contextKeyService),n=I.ob.CanResolve.bindTo(this._contextKeyService);return this._toDispose.add((0,h.s)((()=>{i.reset(),s.reset(),n.reset()}))),this._toDispose.add(e.onDidFocus((({item:e})=>{const t=this.editor.getPosition(),r=e.editStart.column,o=t.column;let a=!0;if("smart"===this.editor.getOption(1)&&2===this.model.state&&!e.completion.additionalTextEdits&&!(4&e.completion.insertTextRules)&&o-r===e.completion.insertText.length){a=this.editor.getModel().getValueInRange({startLineNumber:t.lineNumber,startColumn:r,endLineNumber:t.lineNumber,endColumn:o})!==e.completion.insertText}i.set(a),s.set(!_.y.equals(e.editInsertEnd,e.editReplaceEnd)),n.set(Boolean(e.provider.resolveCompletionItem)||Boolean(e.completion.documentation)||e.completion.detail!==e.completion.label)}))),this._toDispose.add(e.onDetailsKeyDown((e=>{e.toKeyCodeChord().equals(new c.dG(!0,!1,!1,!1,33))||d.zx&&e.toKeyCodeChord().equals(new c.dG(!1,!1,!1,!0,33))?e.stopPropagation():e.toKeyCodeChord().isModifierKey()||this.editor.focus()}))),e}))),this._overtypingCapturer=this._toDispose.add(new B.Ij((0,B.zk)(e.getDomNode()),(()=>this._toDispose.add(new H(this.editor,this.model))))),this._alternatives=this._toDispose.add(new B.Ij((0,B.zk)(e.getDomNode()),(()=>this._toDispose.add(new M(this.editor,this._contextKeyService))))),this._toDispose.add(n.createInstance(R,e)),this._toDispose.add(this.model.onDidTrigger((e=>{this.widget.value.showTriggered(e.auto,e.shy?250:50),this._lineSuffix.value=new Ge(this.editor.getModel(),e.position)}))),this._toDispose.add(this.model.onDidSuggest((e=>{if(e.triggerOptions.shy)return;let t=-1;for(const s of this._selectors.itemsOrderedByPriorityDesc)if(t=s.select(this.editor.getModel(),this.editor.getPosition(),e.completionModel.items),-1!==t)break;if(-1===t&&(t=0),0===this.model.state)return;let i=!1;if(e.triggerOptions.auto){const t=this.editor.getOption(119);"never"===t.selectionMode||"always"===t.selectionMode?i="never"===t.selectionMode:"whenTriggerCharacter"===t.selectionMode?i=1!==e.triggerOptions.triggerKind:"whenQuickSuggestion"===t.selectionMode&&(i=1===e.triggerOptions.triggerKind&&!e.triggerOptions.refilter)}this.widget.value.showSuggestions(e.completionModel,t,e.isFrozen,e.triggerOptions.auto,i)}))),this._toDispose.add(this.model.onDidCancel((e=>{e.retrigger||this.widget.value.hideWidget()}))),this._toDispose.add(this.editor.onDidBlurEditorWidget((()=>{this.model.cancel(),this.model.clear()})));const u=I.ob.AcceptSuggestionsOnEnter.bindTo(s),g=()=>{const e=this.editor.getOption(1);u.set("on"===e||"smart"===e)};this._toDispose.add(this.editor.onDidChangeConfiguration((()=>g()))),g()}dispose(){this._alternatives.dispose(),this._toDispose.dispose(),this.widget.dispose(),this.model.dispose(),this._lineSuffix.dispose(),this._onWillInsertSuggestItem.dispose()}_insertSuggestion(e,t){if(!e||!e.item)return this._alternatives.value.reset(),this.model.cancel(),void this.model.clear();if(!this.editor.hasModel())return;const i=b.O.get(this.editor);if(!i)return;this._onWillInsertSuggestItem.fire({item:e.item});const s=this.editor.getModel(),n=s.getAlternativeVersionId(),{item:r}=e,l=[],c=new o.Qi;1&t||this.editor.pushUndoStop();const h=this.getOverwriteInfo(r,Boolean(8&t));this._memoryService.memorize(s,this.editor.getPosition(),r);const d=r.isResolved;let g=-1,m=-1;if(Array.isArray(r.completion.additionalTextEdits)){this.model.cancel();const e=p.D.capture(this.editor);this.editor.executeEdits("suggestController.additionalTextEdits.sync",r.completion.additionalTextEdits.map((e=>{let t=v.Q.lift(e.range);if(t.startLineNumber===r.position.lineNumber&&t.startColumn>r.position.column){const e=this.editor.getPosition().column-r.position.column,i=e,s=v.Q.spansMultipleLines(t)?0:e;t=new v.Q(t.startLineNumber,t.startColumn+i,t.endLineNumber,t.endColumn+s)}return f.k.replaceMove(t,e.text)}))),e.restoreRelativeVerticalPositionOfCursor(this.editor)}else if(!d){const e=new u.W;let i;const n=s.onDidChangeContent((e=>{if(e.isFlush)return c.cancel(),void n.dispose();for(const t of e.changes){const e=v.Q.getEndPosition(t.range);i&&!_.y.isBefore(e,i)||(i=e)}})),o=t;t|=2;let a=!1;const h=this.editor.onWillType((()=>{h.dispose(),a=!0,2&o||this.editor.pushUndoStop()}));l.push(r.resolve(c.token).then((()=>{if(!r.completion.additionalTextEdits||c.token.isCancellationRequested)return;if(i&&r.completion.additionalTextEdits.some((e=>_.y.isBefore(i,v.Q.getStartPosition(e.range)))))return!1;a&&this.editor.pushUndoStop();const e=p.D.capture(this.editor);return this.editor.executeEdits("suggestController.additionalTextEdits.async",r.completion.additionalTextEdits.map((e=>f.k.replaceMove(v.Q.lift(e.range),e.text)))),e.restoreRelativeVerticalPositionOfCursor(this.editor),!a&&2&o||this.editor.pushUndoStop(),!0})).then((t=>{this._logService.trace("[suggest] async resolving of edits DONE (ms, applied?)",e.elapsed(),t),m=!0===t?1:!1===t?0:-2})).finally((()=>{n.dispose(),h.dispose()})))}let{insertText:C}=r.completion;if(4&r.completion.insertTextRules||(C=E.fr.escape(C)),this.model.cancel(),i.insert(C,{overwriteBefore:h.overwriteBefore,overwriteAfter:h.overwriteAfter,undoStopBefore:!1,undoStopAfter:!1,adjustWhitespace:!(1&r.completion.insertTextRules),clipboardText:e.model.clipboardText,overtypingCapturer:this._overtypingCapturer.value}),2&t||this.editor.pushUndoStop(),r.completion.command)if(r.completion.command.id===Ye.id)this.model.trigger({auto:!0,retrigger:!0});else{const e=new u.W;l.push(this._commandService.executeCommand(r.completion.command.id,...r.completion.command.arguments?[...r.completion.command.arguments]:[]).catch((e=>{r.completion.extensionId?(0,a.M_)(e):(0,a.dz)(e)})).finally((()=>{g=e.elapsed()})))}4&t&&this._alternatives.value.set(e,(e=>{for(c.cancel();s.canUndo();){n!==s.getAlternativeVersionId()&&s.undo(),this._insertSuggestion(e,3|(8&t?8:0));break}})),this._alertCompletionItem(r),Promise.all(l).finally((()=>{this._reportSuggestionAcceptedTelemetry(r,s,d,g,m,e.index,e.model.items),this.model.clear(),c.dispose()}))}_reportSuggestionAcceptedTelemetry(e,t,i,s,n,r,o){if(0===Math.floor(100*Math.random()))return;const a=new Map;for(let h=0;h1?l[0]:-1;this._telemetryService.publicLog2("suggest.acceptedSuggestion",{extensionId:e.extensionId?.value??"unknown",providerId:e.provider._debugDisplayName??"unknown",kind:e.completion.kind,basenameHash:(0,Be.tW)((0,He.P8)(t.uri)).toString(16),languageId:t.getLanguageId(),fileExtension:(0,He.LC)(t.uri),resolveInfo:e.provider.resolveCompletionItem?i?1:0:-1,resolveDuration:e.resolveDuration,commandDuration:s,additionalEditsAsync:n,index:r,firstIndex:c})}getOverwriteInfo(e,t){(0,g.j)(this.editor.hasModel());let i="replace"===this.editor.getOption(119).insertMode;t&&(i=!i);const s=e.position.column-e.editStart.column,n=(i?e.editReplaceEnd.column:e.editInsertEnd.column)-e.position.column;return{overwriteBefore:s+(this.editor.getPosition().column-e.position.column),overwriteAfter:n+(this._lineSuffix.value?this._lineSuffix.value.delta(this.editor.getPosition()):0)}}_alertCompletionItem(e){if((0,r.EI)(e.completion.additionalTextEdits)){const t=x.kg("aria.alert.snippet","Accepting '{0}' made {1} additional edits",e.textLabel,e.completion.additionalTextEdits.length);(0,n.xE)(t)}}triggerSuggest(e,t,i){this.editor.hasModel()&&(this.model.trigger({auto:t??!1,completionOptions:{providerFilter:e,kindFilter:i?new Set:void 0}}),this.editor.revealPosition(this.editor.getPosition(),0),this.editor.focus())}triggerSuggestAndAcceptBest(e){if(!this.editor.hasModel())return;const t=this.editor.getPosition(),i=()=>{t.equals(this.editor.getPosition())&&this._commandService.executeCommand(e.fallback)},s=e=>{if(4&e.completion.insertTextRules||e.completion.additionalTextEdits)return!0;const t=this.editor.getPosition(),i=e.editStart.column,s=t.column;if(s-i!==e.completion.insertText.length)return!0;return this.editor.getModel().getValueInRange({startLineNumber:t.lineNumber,startColumn:i,endLineNumber:t.lineNumber,endColumn:s})!==e.completion.insertText};l.Jh.once(this.model.onDidTrigger)((e=>{const t=[];l.Jh.any(this.model.onDidTrigger,this.model.onDidCancel)((()=>{(0,h.AS)(t),i()}),void 0,t),this.model.onDidSuggest((({completionModel:e})=>{if((0,h.AS)(t),0===e.items.length)return void i();const n=this._memoryService.select(this.editor.getModel(),this.editor.getPosition(),e.items),r=e.items[n];s(r)?(this.editor.pushUndoStop(),this._insertSuggestion({index:n,item:r,model:e},7)):i()}),void 0,t)})),this.model.trigger({auto:!1,shy:!0}),this.editor.revealPosition(t,0),this.editor.focus()}acceptSelectedSuggestion(e,t){const i=this.widget.value.getFocusedItem();let s=0;e&&(s|=4),t&&(s|=8),this._insertSuggestion(i,s)}acceptNextSuggestion(){this._alternatives.value.next()}acceptPrevSuggestion(){this._alternatives.value.prev()}cancelSuggestWidget(){this.model.cancel(),this.model.clear(),this.widget.value.hideWidget()}focusSuggestion(){this.widget.value.focusSelected()}selectNextSuggestion(){this.widget.value.selectNext()}selectNextPageSuggestion(){this.widget.value.selectNextPage()}selectLastSuggestion(){this.widget.value.selectLast()}selectPrevSuggestion(){this.widget.value.selectPrevious()}selectPrevPageSuggestion(){this.widget.value.selectPreviousPage()}selectFirstSuggestion(){this.widget.value.selectFirst()}toggleSuggestionDetails(){this.widget.value.toggleDetails()}toggleExplainMode(){this.widget.value.toggleExplainMode()}toggleSuggestionFocus(){this.widget.value.toggleDetailsFocus()}resetWidgetSize(){this.widget.value.resetPersistedSize()}forceRenderingAbove(){this.widget.value.forceRenderingAbove()}stopForceRenderingAbove(){this.widget.isInitialized&&this.widget.value.stopForceRenderingAbove()}registerSelector(e){return this._selectors.register(e)}};je=Fe=Ve([ze(1,S.GS),ze(2,k.d),ze(3,y.fN),ze(4,A._Y),ze(5,N.rr),ze(6,Ue.k)],je);class Ke{constructor(e){this.prioritySelector=e,this._items=new Array}register(e){if(-1!==this._items.indexOf(e))throw new Error("Value is already registered");return this._items.push(e),this._items.sort(((e,t)=>this.prioritySelector(t)-this.prioritySelector(e))),{dispose:()=>{const t=this._items.indexOf(e);t>=0&&this._items.splice(t,1)}}}get itemsOrderedByPriorityDesc(){return this._items}}class Ye extends m.ks{static{this.id="editor.action.triggerSuggest"}constructor(){super({id:Ye.id,label:x.kg("suggest.trigger.label","Trigger Suggest"),alias:"Trigger Suggest",precondition:y.M$.and(C.R.writable,C.R.hasCompletionItemProvider,I.ob.Visible.toNegated()),kbOpts:{kbExpr:C.R.textInputFocus,primary:2058,secondary:[2087],mac:{primary:266,secondary:[521,2087]},weight:100}})}run(e,t,i){const s=je.get(t);if(!s)return;let n;i&&"object"===typeof i&&!0===i.auto&&(n=!0),s.triggerSuggest(void 0,n,void 0)}}(0,m.HW)(je.ID,je,2),(0,m.Fl)(Ye);const qe=190,$e=m.DX.bindToContribution(je.get);(0,m.E_)(new $e({id:"acceptSelectedSuggestion",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion),handler(e){e.acceptSelectedSuggestion(!0,!1)},kbOpts:[{primary:2,kbExpr:y.M$.and(I.ob.Visible,C.R.textInputFocus),weight:qe},{primary:3,kbExpr:y.M$.and(I.ob.Visible,C.R.textInputFocus,I.ob.AcceptSuggestionsOnEnter,I.ob.MakesTextEdit),weight:qe}],menuOpts:[{menuId:I.dt,title:x.kg("accept.insert","Insert"),group:"left",order:1,when:I.ob.HasInsertAndReplaceRange.toNegated()},{menuId:I.dt,title:x.kg("accept.insert","Insert"),group:"left",order:1,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("insert"))},{menuId:I.dt,title:x.kg("accept.replace","Replace"),group:"left",order:1,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("replace"))}]})),(0,m.E_)(new $e({id:"acceptAlternativeSelectedSuggestion",precondition:y.M$.and(I.ob.Visible,C.R.textInputFocus,I.ob.HasFocusedSuggestion),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:1027,secondary:[1026]},handler(e){e.acceptSelectedSuggestion(!1,!0)},menuOpts:[{menuId:I.dt,group:"left",order:2,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("insert")),title:x.kg("accept.replace","Replace")},{menuId:I.dt,group:"left",order:2,when:y.M$.and(I.ob.HasInsertAndReplaceRange,I.ob.InsertMode.isEqualTo("replace")),title:x.kg("accept.insert","Insert")}]})),k.w.registerCommandAlias("acceptSelectedSuggestionOnEnter","acceptSelectedSuggestion"),(0,m.E_)(new $e({id:"hideSuggestWidget",precondition:I.ob.Visible,handler:e=>e.cancelSuggestWidget(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:9,secondary:[1033]}})),(0,m.E_)(new $e({id:"selectNextSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectNextSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:18,secondary:[2066],mac:{primary:18,secondary:[2066,300]}}})),(0,m.E_)(new $e({id:"selectNextPageSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectNextPageSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:12,secondary:[2060]}})),(0,m.E_)(new $e({id:"selectLastSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectLastSuggestion()})),(0,m.E_)(new $e({id:"selectPrevSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectPrevSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:16,secondary:[2064],mac:{primary:16,secondary:[2064,302]}}})),(0,m.E_)(new $e({id:"selectPrevPageSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectPrevPageSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:11,secondary:[2059]}})),(0,m.E_)(new $e({id:"selectFirstSuggestion",precondition:y.M$.and(I.ob.Visible,y.M$.or(I.ob.MultipleSuggestions,I.ob.HasFocusedSuggestion.negate())),handler:e=>e.selectFirstSuggestion()})),(0,m.E_)(new $e({id:"focusSuggestion",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion.negate()),handler:e=>e.focusSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2058,secondary:[2087],mac:{primary:266,secondary:[2087]}}})),(0,m.E_)(new $e({id:"focusAndAcceptSuggestion",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion.negate()),handler:e=>{e.focusSuggestion(),e.acceptSelectedSuggestion(!0,!1)}})),(0,m.E_)(new $e({id:"toggleSuggestionDetails",precondition:y.M$.and(I.ob.Visible,I.ob.HasFocusedSuggestion),handler:e=>e.toggleSuggestionDetails(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2058,secondary:[2087],mac:{primary:266,secondary:[2087]}},menuOpts:[{menuId:I.dt,group:"right",order:1,when:y.M$.and(I.ob.DetailsVisible,I.ob.CanResolve),title:x.kg("detail.more","Show Less")},{menuId:I.dt,group:"right",order:1,when:y.M$.and(I.ob.DetailsVisible.toNegated(),I.ob.CanResolve),title:x.kg("detail.less","Show More")}]})),(0,m.E_)(new $e({id:"toggleExplainMode",precondition:I.ob.Visible,handler:e=>e.toggleExplainMode(),kbOpts:{weight:100,primary:2138}})),(0,m.E_)(new $e({id:"toggleSuggestionFocus",precondition:I.ob.Visible,handler:e=>e.toggleSuggestionFocus(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2570,mac:{primary:778}}})),(0,m.E_)(new $e({id:"insertBestCompletion",precondition:y.M$.and(C.R.textInputFocus,y.M$.equals("config.editor.tabCompletion","on"),R.AtEnd,I.ob.Visible.toNegated(),M.OtherSuggestions.toNegated(),b.O.InSnippetMode.toNegated()),handler:(e,t)=>{e.triggerSuggestAndAcceptBest((0,g.Gv)(t)?{fallback:"tab",...t}:{fallback:"tab"})},kbOpts:{weight:qe,primary:2}})),(0,m.E_)(new $e({id:"insertNextSuggestion",precondition:y.M$.and(C.R.textInputFocus,y.M$.equals("config.editor.tabCompletion","on"),M.OtherSuggestions,I.ob.Visible.toNegated(),b.O.InSnippetMode.toNegated()),handler:e=>e.acceptNextSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:2}})),(0,m.E_)(new $e({id:"insertPrevSuggestion",precondition:y.M$.and(C.R.textInputFocus,y.M$.equals("config.editor.tabCompletion","on"),M.OtherSuggestions,I.ob.Visible.toNegated(),b.O.InSnippetMode.toNegated()),handler:e=>e.acceptPrevSuggestion(),kbOpts:{weight:qe,kbExpr:C.R.textInputFocus,primary:1026}})),(0,m.Fl)(class extends m.ks{constructor(){super({id:"editor.action.resetSuggestSize",label:x.kg("suggest.reset.label","Reset Suggest Widget Size"),alias:"Reset Suggest Widget Size",precondition:void 0})}run(e,t){je.get(t)?.resetWidgetSize()}})},10846:(e,t,i)=>{"use strict";var s=i(18447),n=i(26690),r=i(42522),o=i(5662),a=i(80301),l=i(36677),c=i(72466),h=i(56942),d=i(51173),u=i(48116),g=i(88415),p=i(96299),m=i(14055),f=i(54770),_=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},v=function(e,t){return function(i,s){t(i,s,e)}};class C{constructor(e,t,i,s,n,r){this.range=e,this.insertText=t,this.filterText=i,this.additionalTextEdits=s,this.command=n,this.completion=r}}let b=class extends o.mp{constructor(e,t,i,s,n,r){super(n.disposable),this.model=e,this.line=t,this.word=i,this.completionModel=s,this._suggestMemoryService=r}canBeReused(e,t,i){return this.model===e&&this.line===t&&this.word.word.length>0&&this.word.startColumn===i.startColumn&&this.word.endColumn=0&&h.resolve(s.XO.None)}return e}};b=_([v(5,g.GS)],b);let E=class extends o.jG{constructor(e,t,i,s){super(),this._languageFeatureService=e,this._clipboardService=t,this._suggestMemoryService=i,this._editorService=s,this._store.add(e.inlineCompletionsProvider.register("*",this))}async provideInlineCompletions(e,t,i,s){if(i.selectedSuggestionInfo)return;let n;for(const l of this._editorService.listCodeEditors())if(l.getModel()===e){n=l;break}if(!n)return;const r=n.getOption(90);if(u.r3.isAllOff(r))return;e.tokenization.tokenizeIfCheap(t.lineNumber);const o=e.tokenization.getLineTokens(t.lineNumber),a=o.getStandardTokenType(o.findTokenIndexAtOffset(Math.max(t.column-1-1,0)));if("inline"!==u.r3.valueFor(r,a))return;let c,h,g=e.getWordAtPosition(t);if(g?.word||(c=this._getTriggerCharacterInfo(e,t)),!g?.word&&!c)return;if(g||(g=e.getWordUntilPosition(t)),g.endColumn!==t.column)return;const f=e.getValueInRange(new l.Q(t.lineNumber,1,t.lineNumber,t.column));if(!c&&this._lastResult?.canBeReused(e,t.lineNumber,g)){const e=new d.O(f,t.column-this._lastResult.word.endColumn);this._lastResult.completionModel.lineContext=e,this._lastResult.acquire(),h=this._lastResult}else{const i=await(0,u.aR)(this._languageFeatureService.completionProvider,e,t,new u.l1(void 0,p.Y.createSuggestFilter(n).itemKind,c?.providers),c&&{triggerKind:1,triggerCharacter:c.ch},s);let r;i.needsClipboard&&(r=await this._clipboardService.readText());const o=new d.C(i.items,t.column,new d.O(f,0),m.S.None,n.getOption(119),n.getOption(113),{boostFullMatch:!1,firstMatchCanBeWeak:!1},r);h=new b(e,t.lineNumber,g,o,i,this._suggestMemoryService)}return this._lastResult=h,h}handleItemDidShow(e,t){t.completion.resolve(s.XO.None)}freeInlineCompletions(e){e.release()}_getTriggerCharacterInfo(e,t){const i=e.getValueInRange(l.Q.fromPositions({lineNumber:t.lineNumber,column:t.column-1},t)),s=new Set;for(const n of this._languageFeatureService.completionProvider.all(e))n.triggerCharacters?.includes(i)&&s.add(n);if(0!==s.size)return{providers:s,ch:i}}};E=_([v(0,h.ILanguageFeaturesService),v(1,f.h),v(2,g.GS),v(3,a.T)],E),(0,c.x)(E)},88415:(e,t,i)=>{"use strict";i.d(t,{GS:()=>b});var s,n=i(90766),r=i(5662),o=i(74320),a=i(4853),l=i(62083),c=i(84001),h=i(14718),d=i(63591),u=i(9711),g=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},p=function(e,t){return function(i,s){t(i,s,e)}};class m{constructor(e){this.name=e}select(e,t,i){if(0===i.length)return 0;const s=i[0].score[0];for(let n=0;na&&s.type===i[l].completion.kind&&s.insertText===i[l].completion.insertText&&(a=s.touch,o=l),i[l].completion.preselect&&-1===r)return l}return-1!==o?o:-1!==r?r:0}toJSON(){return this._cache.toJSON()}fromJSON(e){this._cache.clear();for(const[t,i]of e)i.touch=0,i.type="number"===typeof i.type?i.type:l.HC.fromString(i.type),this._cache.set(t,i);this._seq=this._cache.size}}class v extends m{constructor(){super("recentlyUsedByPrefix"),this._trie=a.cB.forStrings(),this._seq=0}memorize(e,t,i){const{word:s}=e.getWordUntilPosition(t),n=`${e.getLanguageId()}/${s}`;this._trie.set(n,{type:i.completion.kind,insertText:i.completion.insertText,touch:this._seq++})}select(e,t,i){const{word:s}=e.getWordUntilPosition(t);if(!s)return super.select(e,t,i);const n=`${e.getLanguageId()}/${s}`;let r=this._trie.get(n);if(r||(r=this._trie.findSubstr(n)),r)for(let o=0;oe.push([i,t]))),e.sort(((e,t)=>-(e[1].touch-t[1].touch))).forEach(((e,t)=>e[1].touch=t)),e.slice(0,200)}fromJSON(e){if(this._trie.clear(),e.length>0){this._seq=e[0][1].touch+1;for(const[t,i]of e)i.type="number"===typeof i.type?i.type:l.HC.fromString(i.type),this._trie.set(t,i)}}}let C=class{static{s=this}static{this._strategyCtors=new Map([["recentlyUsedByPrefix",v],["recentlyUsed",_],["first",f]])}static{this._storagePrefix="suggest/memories"}constructor(e,t){this._storageService=e,this._configService=t,this._disposables=new r.Cm,this._persistSoon=new n.uC((()=>this._saveState()),500),this._disposables.add(e.onWillSaveState((e=>{e.reason===u.LP.SHUTDOWN&&this._saveState()})))}dispose(){this._disposables.dispose(),this._persistSoon.dispose()}memorize(e,t,i){this._withStrategy(e,t).memorize(e,t,i),this._persistSoon.schedule()}select(e,t,i){return this._withStrategy(e,t).select(e,t,i)}_withStrategy(e,t){const i=this._configService.getValue("editor.suggestSelection",{overrideIdentifier:e.getLanguageIdAtPosition(t.lineNumber,t.column),resource:e.uri});if(this._strategy?.name!==i){this._saveState();const e=s._strategyCtors.get(i)||f;this._strategy=new e;try{const e=this._configService.getValue("editor.suggest.shareSuggestSelections")?0:1,t=this._storageService.get(`${s._storagePrefix}/${i}`,e);t&&this._strategy.fromJSON(JSON.parse(t))}catch(n){}}return this._strategy}_saveState(){if(this._strategy){const e=this._configService.getValue("editor.suggest.shareSuggestSelections")?0:1,t=JSON.stringify(this._strategy);this._storageService.store(`${s._storagePrefix}/${this._strategy.name}`,t,e,1)}}};C=s=g([p(0,u.CS),p(1,c.pG)],C);const b=(0,d.u1)("ISuggestMemories");(0,h.v)(b,C,1)},96299:(e,t,i)=>{"use strict";i.d(t,{Y:()=>k});var s,n=i(90766),r=i(18447),o=i(64383),a=i(41234),l=i(5662),c=i(91508),h=i(75326),d=i(10920),u=i(14055),g=i(54770),p=i(84001),m=i(32848),f=i(18801),_=i(90651),v=i(51173),C=i(48116),b=i(56942),E=i(26690),S=i(631),y=i(62051),w=i(30936),L=i(97035),R=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},T=function(e,t){return function(i,s){t(i,s,e)}};class x{static shouldAutoTrigger(e){if(!e.hasModel())return!1;const t=e.getModel(),i=e.getPosition();t.tokenization.tokenizeIfCheap(i.lineNumber);const s=t.getWordAtPosition(i);return!!s&&((s.endColumn===i.column||s.startColumn+1===i.column)&&!!isNaN(Number(s.word)))}constructor(e,t,i){this.leadingLineContent=e.getLineContent(t.lineNumber).substr(0,t.column-1),this.leadingWord=e.getWordUntilPosition(t),this.lineNumber=t.lineNumber,this.column=t.column,this.triggerOptions=i}}let k=s=class{constructor(e,t,i,s,r,o,c,d,u){this._editor=e,this._editorWorkerService=t,this._clipboardService=i,this._telemetryService=s,this._logService=r,this._contextKeyService=o,this._configurationService=c,this._languageFeaturesService=d,this._envService=u,this._toDispose=new l.Cm,this._triggerCharacterListener=new l.Cm,this._triggerQuickSuggest=new n.pc,this._triggerState=void 0,this._completionDisposables=new l.Cm,this._onDidCancel=new a.vl,this._onDidTrigger=new a.vl,this._onDidSuggest=new a.vl,this.onDidCancel=this._onDidCancel.event,this.onDidTrigger=this._onDidTrigger.event,this.onDidSuggest=this._onDidSuggest.event,this._telemetryGate=0,this._currentSelection=this._editor.getSelection()||new h.L(1,1,1,1),this._toDispose.add(this._editor.onDidChangeModel((()=>{this._updateTriggerCharacters(),this.cancel()}))),this._toDispose.add(this._editor.onDidChangeModelLanguage((()=>{this._updateTriggerCharacters(),this.cancel()}))),this._toDispose.add(this._editor.onDidChangeConfiguration((()=>{this._updateTriggerCharacters()}))),this._toDispose.add(this._languageFeaturesService.completionProvider.onDidChange((()=>{this._updateTriggerCharacters(),this._updateActiveSuggestSession()})));let g=!1;this._toDispose.add(this._editor.onDidCompositionStart((()=>{g=!0}))),this._toDispose.add(this._editor.onDidCompositionEnd((()=>{g=!1,this._onCompositionEnd()}))),this._toDispose.add(this._editor.onDidChangeCursorSelection((e=>{g||this._onCursorChange(e)}))),this._toDispose.add(this._editor.onDidChangeModelContent((()=>{g||void 0===this._triggerState||this._refilterCompletionItems()}))),this._updateTriggerCharacters()}dispose(){(0,l.AS)(this._triggerCharacterListener),(0,l.AS)([this._onDidCancel,this._onDidSuggest,this._onDidTrigger,this._triggerQuickSuggest]),this._toDispose.dispose(),this._completionDisposables.dispose(),this.cancel()}_updateTriggerCharacters(){if(this._triggerCharacterListener.clear(),this._editor.getOption(92)||!this._editor.hasModel()||!this._editor.getOption(122))return;const e=new Map;for(const i of this._languageFeaturesService.completionProvider.all(this._editor.getModel()))for(const t of i.triggerCharacters||[]){let s=e.get(t);if(!s){s=new Set;const i=(0,C.f3)();i&&s.add(i),e.set(t,s)}s.add(i)}const t=t=>{if(!function(e,t){if(!Boolean(t.getContextKeyValue("inlineSuggestionVisible")))return!0;const i=t.getContextKeyValue(y.p.suppressSuggestions.key);return void 0!==i?!i:!e.getOption(62).suppressSuggestions}(this._editor,this._contextKeyService,this._configurationService))return;if(x.shouldAutoTrigger(this._editor))return;if(!t){const e=this._editor.getPosition();t=this._editor.getModel().getLineContent(e.lineNumber).substr(0,e.column-1)}let i="";(0,c.LJ)(t.charCodeAt(t.length-1))?(0,c.pc)(t.charCodeAt(t.length-2))&&(i=t.substr(t.length-2)):i=t.charAt(t.length-1);const s=e.get(i);if(s){const e=new Map;if(this._completionModel)for(const[t,i]of this._completionModel.getItemsByProvider())s.has(t)||e.set(t,i);this.trigger({auto:!0,triggerKind:1,triggerCharacter:i,retrigger:Boolean(this._completionModel),clipboardText:this._completionModel?.clipboardText,completionOptions:{providerFilter:s,providerItemsToReuse:e}})}};this._triggerCharacterListener.add(this._editor.onDidType(t)),this._triggerCharacterListener.add(this._editor.onDidCompositionEnd((()=>t())))}get state(){return this._triggerState?this._triggerState.auto?2:1:0}cancel(e=!1){void 0!==this._triggerState&&(this._triggerQuickSuggest.cancel(),this._requestToken?.cancel(),this._requestToken=void 0,this._triggerState=void 0,this._completionModel=void 0,this._context=void 0,this._onDidCancel.fire({retrigger:e}))}clear(){this._completionDisposables.clear()}_updateActiveSuggestSession(){void 0!==this._triggerState&&(this._editor.hasModel()&&this._languageFeaturesService.completionProvider.has(this._editor.getModel())?this.trigger({auto:this._triggerState.auto,retrigger:!0}):this.cancel())}_onCursorChange(e){if(!this._editor.hasModel())return;const t=this._currentSelection;this._currentSelection=this._editor.getSelection(),!e.selection.isEmpty()||0!==e.reason&&3!==e.reason||"keyboard"!==e.source&&"deleteLeft"!==e.source?this.cancel():void 0===this._triggerState&&0===e.reason?(t.containsRange(this._currentSelection)||t.getEndPosition().isBeforeOrEqual(this._currentSelection.getPosition()))&&this._doTriggerQuickSuggest():void 0!==this._triggerState&&3===e.reason&&this._refilterCompletionItems()}_onCompositionEnd(){void 0===this._triggerState?this._doTriggerQuickSuggest():this._refilterCompletionItems()}_doTriggerQuickSuggest(){C.r3.isAllOff(this._editor.getOption(90))||this._editor.getOption(119).snippetsPreventQuickSuggestions&&w.O.get(this._editor)?.isInSnippet()||(this.cancel(),this._triggerQuickSuggest.cancelAndSet((()=>{if(void 0!==this._triggerState)return;if(!x.shouldAutoTrigger(this._editor))return;if(!this._editor.hasModel()||!this._editor.hasWidgetFocus())return;const e=this._editor.getModel(),t=this._editor.getPosition(),i=this._editor.getOption(90);if(!C.r3.isAllOff(i)){if(!C.r3.isAllOn(i)){e.tokenization.tokenizeIfCheap(t.lineNumber);const s=e.tokenization.getLineTokens(t.lineNumber),n=s.getStandardTokenType(s.findTokenIndexAtOffset(Math.max(t.column-1-1,0)));if("on"!==C.r3.valueFor(i,n))return}(function(e,t){if(!Boolean(t.getContextKeyValue(y.p.inlineSuggestionVisible.key)))return!0;const i=t.getContextKeyValue(y.p.suppressSuggestions.key);return void 0!==i?!i:!e.getOption(62).suppressSuggestions})(this._editor,this._contextKeyService,this._configurationService)&&this._languageFeaturesService.completionProvider.has(e)&&this.trigger({auto:!0})}}),this._editor.getOption(91)))}_refilterCompletionItems(){(0,S.j)(this._editor.hasModel()),(0,S.j)(void 0!==this._triggerState);const e=this._editor.getModel(),t=this._editor.getPosition(),i=new x(e,t,{...this._triggerState,refilter:!0});this._onNewContext(i)}trigger(e){if(!this._editor.hasModel())return;const t=this._editor.getModel(),i=new x(t,this._editor.getPosition(),e);this.cancel(e.retrigger),this._triggerState=e,this._onDidTrigger.fire({auto:e.auto,shy:e.shy??!1,position:this._editor.getPosition()}),this._context=i;let n={triggerKind:e.triggerKind??0};e.triggerCharacter&&(n={triggerKind:1,triggerCharacter:e.triggerCharacter}),this._requestToken=new r.Qi;let a=1;switch(this._editor.getOption(113)){case"top":a=0;break;case"bottom":a=2}const{itemKind:l,showDeprecated:c}=s.createSuggestFilter(this._editor),h=new C.l1(a,e.completionOptions?.kindFilter??l,e.completionOptions?.providerFilter,e.completionOptions?.providerItemsToReuse,c),d=u.S.create(this._editorWorkerService,this._editor),g=(0,C.aR)(this._languageFeaturesService.completionProvider,t,this._editor.getPosition(),h,n,this._requestToken.token);Promise.all([g,d]).then((async([t,i])=>{if(this._requestToken?.dispose(),!this._editor.hasModel())return;let s=e?.clipboardText;if(!s&&t.needsClipboard&&(s=await this._clipboardService.readText()),void 0===this._triggerState)return;const n=this._editor.getModel(),r=new x(n,this._editor.getPosition(),e),o={...E.Nd.default,firstMatchCanBeWeak:!this._editor.getOption(119).matchOnWordStartOnly};if(this._completionModel=new v.C(t.items,this._context.column,{leadingLineContent:r.leadingLineContent,characterCountDelta:r.column-this._context.column},i,this._editor.getOption(119),this._editor.getOption(113),o,s),this._completionDisposables.add(t.disposable),this._onNewContext(r),this._reportDurationsTelemetry(t.durations),!this._envService.isBuilt||this._envService.isExtensionDevelopment)for(const e of t.items)e.isInvalid&&this._logService.warn(`[suggest] did IGNORE invalid completion item from ${e.provider._debugDisplayName}`,e.completion)})).catch(o.dz)}_reportDurationsTelemetry(e){this._telemetryGate++%230===0&&setTimeout((()=>{this._telemetryService.publicLog2("suggest.durations.json",{data:JSON.stringify(e)}),this._logService.debug("suggest.durations.json",e)}))}static createSuggestFilter(e){const t=new Set;"none"===e.getOption(113)&&t.add(27);const i=e.getOption(119);return i.showMethods||t.add(0),i.showFunctions||t.add(1),i.showConstructors||t.add(2),i.showFields||t.add(3),i.showVariables||t.add(4),i.showClasses||t.add(5),i.showStructs||t.add(6),i.showInterfaces||t.add(7),i.showModules||t.add(8),i.showProperties||t.add(9),i.showEvents||t.add(10),i.showOperators||t.add(11),i.showUnits||t.add(12),i.showValues||t.add(13),i.showConstants||t.add(14),i.showEnums||t.add(15),i.showEnumMembers||t.add(16),i.showKeywords||t.add(17),i.showWords||t.add(18),i.showColors||t.add(19),i.showFiles||t.add(20),i.showReferences||t.add(21),i.showColors||t.add(22),i.showFolders||t.add(23),i.showTypeParameters||t.add(24),i.showSnippets||t.add(27),i.showUsers||t.add(25),i.showIssues||t.add(26),{itemKind:t,showDeprecated:i.showDeprecated}}_onNewContext(e){if(this._context)if(e.lineNumber===this._context.lineNumber)if((0,c.UU)(e.leadingLineContent)===(0,c.UU)(this._context.leadingLineContent)){if(e.columnthis._context.leadingWord.startColumn){if(x.shouldAutoTrigger(this._editor)&&this._context){const e=this._completionModel.getItemsByProvider();this.trigger({auto:this._context.triggerOptions.auto,retrigger:!0,clipboardText:this._completionModel.clipboardText,completionOptions:{providerItemsToReuse:e}})}}else if(e.column>this._context.column&&this._completionModel.getIncompleteProvider().size>0&&0!==e.leadingWord.word.length){const e=new Map,t=new Set;for(const[i,s]of this._completionModel.getItemsByProvider())s.length>0&&s[0].container.incomplete?t.add(i):e.set(i,s);this.trigger({auto:this._context.triggerOptions.auto,triggerKind:2,retrigger:!0,clipboardText:this._completionModel.clipboardText,completionOptions:{providerFilter:t,providerItemsToReuse:e}})}else{const t=this._completionModel.lineContext;let i=!1;if(this._completionModel.lineContext={leadingLineContent:e.leadingLineContent,characterCountDelta:e.column-this._context.column},0===this._completionModel.items.length){const s=x.shouldAutoTrigger(this._editor);if(!this._context)return void this.cancel();if(s&&this._context.leadingWord.endColumn0,i&&0===e.leadingWord.word.length)return void this.cancel()}this._onDidSuggest.fire({completionModel:this._completionModel,triggerOptions:e.triggerOptions,isFrozen:i})}}else this.cancel();else this.cancel()}};k=s=R([T(1,d.IEditorWorkerService),T(2,g.h),T(3,_.k),T(4,f.rr),T(5,m.fN),T(6,p.pG),T(7,b.ILanguageFeaturesService),T(8,L.k)],k)},14055:(e,t,i)=>{"use strict";i.d(t,{S:()=>o});var s=i(25890),n=i(36677),r=i(39286);class o{static{this.None=new class extends o{distance(){return 0}}}static async create(e,t){if(!t.getOption(119).localityBonus)return o.None;if(!t.hasModel())return o.None;const i=t.getModel(),a=t.getPosition();if(!e.canComputeWordRanges(i.uri))return o.None;const[l]=await(new r.n).provideSelectionRanges(i,[a]);if(0===l.length)return o.None;const c=await e.computeWordRanges(i.uri,l[0].range);if(!c)return o.None;const h=i.getWordUntilPosition(a);return delete c[h.word],new class extends o{distance(e,i){if(!a.equals(t.getPosition()))return 0;if(17===i.kind)return 2<<20;const r="string"===typeof i.label?i.label:i.label.label,o=c[r];if((0,s.Ct)(o))return 2<<20;const h=(0,s.El)(o,n.Q.fromPositions(e),n.Q.compareRangesUsingStarts),d=h>=0?o[h]:o[Math.max(0,~h-1)];let u=l.length;for(const t of l){if(!n.Q.containsRange(t.range,d))break;u-=1}return u}}}}},93409:(e,t,i)=>{"use strict";var s=i(78209),n=i(66261);(0,n.x1A)("symbolIcon.arrayForeground",n.CU6,(0,s.kg)("symbolIcon.arrayForeground","The foreground color for array symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.booleanForeground",n.CU6,(0,s.kg)("symbolIcon.booleanForeground","The foreground color for boolean symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.classForeground",{dark:"#EE9D28",light:"#D67E00",hcDark:"#EE9D28",hcLight:"#D67E00"},(0,s.kg)("symbolIcon.classForeground","The foreground color for class symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.colorForeground",n.CU6,(0,s.kg)("symbolIcon.colorForeground","The foreground color for color symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.constantForeground",n.CU6,(0,s.kg)("symbolIcon.constantForeground","The foreground color for constant symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.constructorForeground",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},(0,s.kg)("symbolIcon.constructorForeground","The foreground color for constructor symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.enumeratorForeground",{dark:"#EE9D28",light:"#D67E00",hcDark:"#EE9D28",hcLight:"#D67E00"},(0,s.kg)("symbolIcon.enumeratorForeground","The foreground color for enumerator symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.enumeratorMemberForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.enumeratorMemberForeground","The foreground color for enumerator member symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.eventForeground",{dark:"#EE9D28",light:"#D67E00",hcDark:"#EE9D28",hcLight:"#D67E00"},(0,s.kg)("symbolIcon.eventForeground","The foreground color for event symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.fieldForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.fieldForeground","The foreground color for field symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.fileForeground",n.CU6,(0,s.kg)("symbolIcon.fileForeground","The foreground color for file symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.folderForeground",n.CU6,(0,s.kg)("symbolIcon.folderForeground","The foreground color for folder symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.functionForeground",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},(0,s.kg)("symbolIcon.functionForeground","The foreground color for function symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.interfaceForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.interfaceForeground","The foreground color for interface symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.keyForeground",n.CU6,(0,s.kg)("symbolIcon.keyForeground","The foreground color for key symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.keywordForeground",n.CU6,(0,s.kg)("symbolIcon.keywordForeground","The foreground color for keyword symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.methodForeground",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},(0,s.kg)("symbolIcon.methodForeground","The foreground color for method symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.moduleForeground",n.CU6,(0,s.kg)("symbolIcon.moduleForeground","The foreground color for module symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.namespaceForeground",n.CU6,(0,s.kg)("symbolIcon.namespaceForeground","The foreground color for namespace symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.nullForeground",n.CU6,(0,s.kg)("symbolIcon.nullForeground","The foreground color for null symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.numberForeground",n.CU6,(0,s.kg)("symbolIcon.numberForeground","The foreground color for number symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.objectForeground",n.CU6,(0,s.kg)("symbolIcon.objectForeground","The foreground color for object symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.operatorForeground",n.CU6,(0,s.kg)("symbolIcon.operatorForeground","The foreground color for operator symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.packageForeground",n.CU6,(0,s.kg)("symbolIcon.packageForeground","The foreground color for package symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.propertyForeground",n.CU6,(0,s.kg)("symbolIcon.propertyForeground","The foreground color for property symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.referenceForeground",n.CU6,(0,s.kg)("symbolIcon.referenceForeground","The foreground color for reference symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.snippetForeground",n.CU6,(0,s.kg)("symbolIcon.snippetForeground","The foreground color for snippet symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.stringForeground",n.CU6,(0,s.kg)("symbolIcon.stringForeground","The foreground color for string symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.structForeground",n.CU6,(0,s.kg)("symbolIcon.structForeground","The foreground color for struct symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.textForeground",n.CU6,(0,s.kg)("symbolIcon.textForeground","The foreground color for text symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.typeParameterForeground",n.CU6,(0,s.kg)("symbolIcon.typeParameterForeground","The foreground color for type parameter symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.unitForeground",n.CU6,(0,s.kg)("symbolIcon.unitForeground","The foreground color for unit symbols. These symbols appear in the outline, breadcrumb, and suggest widget.")),(0,n.x1A)("symbolIcon.variableForeground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},(0,s.kg)("symbolIcon.variableForeground","The foreground color for variable symbols. These symbols appear in the outline, breadcrumb, and suggest widget."))},98472:(e,t,i)=>{"use strict";var s=i(11007),n=i(77163),r=i(78209),o=i(27195);class a extends o.L{static{this.ID="editor.action.toggleTabFocusMode"}constructor(){super({id:a.ID,title:r.aS({key:"toggle.tabMovesFocus",comment:["Turn on/off use of tab key for moving focus around VS Code"]},"Toggle Tab Key Moves Focus"),precondition:void 0,keybinding:{primary:2091,mac:{primary:1323},weight:100},metadata:{description:r.aS("tabMovesFocusDescriptions","Determines whether the tab key moves focus around the workbench or inserts the tab character in the current editor. This is also called tab trapping, tab navigation, or tab focus mode.")},f1:!0})}run(){const e=!n.M.getTabFocusMode();n.M.setTabFocusMode(e),e?(0,s.xE)(r.kg("toggle.tabMovesFocus.on","Pressing Tab will now move focus to the next focusable element")):(0,s.xE)(r.kg("toggle.tabMovesFocus.off","Pressing Tab will now insert the tab character"))}}(0,o.ug)(a)},50166:(e,t,i)=>{"use strict";var s=i(78381),n=i(31450),r=i(78209);class o extends n.ks{constructor(){super({id:"editor.action.forceRetokenize",label:r.kg("forceRetokenize","Developer: Force Retokenize"),alias:"Developer: Force Retokenize",precondition:void 0})}run(e,t){if(!t.hasModel())return;const i=t.getModel();i.tokenization.resetTokenization();const n=new s.W;i.tokenization.forceTokenization(i.getLineCount()),n.stop(),console.log(`tokenization took ${n.elapsed()}`)}}(0,n.Fl)(o)},68887:(e,t,i)=>{"use strict";var s=i(90766),n=i(10350),r=i(16980),o=i(5662),a=i(98067),l=i(91508),c=i(31450),h=i(87908),d=i(87289),u=i(74855),g=i(10920),p=i(10154),m=i(32398),f=i(57039),_=i(57286),v=i(8597),C=i(11799),b=i(36921),E=i(20492),S=i(63591),y=i(56245),w=i(72962),L=i(25154),R=i(41234),T=i(49099),x=i(42904),k=i(67220),A=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},N=function(e,t){return function(i,s){t(i,s,e)}};let I=class extends o.jG{get enabled(){return this._enabled}set enabled(e){e?(this.el.setAttribute("aria-disabled","false"),this.el.tabIndex=0,this.el.style.pointerEvents="auto",this.el.style.opacity="1",this.el.style.cursor="pointer",this._enabled=!1):(this.el.setAttribute("aria-disabled","true"),this.el.tabIndex=-1,this.el.style.pointerEvents="none",this.el.style.opacity="0.4",this.el.style.cursor="default",this._enabled=!0),this._enabled=e}constructor(e,t,i={},s,n){super(),this._link=t,this._hoverService=s,this._enabled=!0,this.el=(0,v.BC)(e,(0,v.$)("a.monaco-link",{tabIndex:t.tabIndex??0,href:t.href},t.label)),this.hoverDelegate=i.hoverDelegate??(0,x.nZ)("mouse"),this.setTooltip(t.title),this.el.setAttribute("role","button");const r=this._register(new y.f(this.el,"click")),o=this._register(new y.f(this.el,"keypress")),a=R.Jh.chain(o.event,(e=>e.map((e=>new w.Z(e))).filter((e=>3===e.keyCode)))),l=this._register(new y.f(this.el,L.B.Tap)).event;this._register(L.q.addTarget(this.el));const c=R.Jh.any(r.event,a,l);this._register(c((e=>{this.enabled&&(v.fs.stop(e,!0),i?.opener?i.opener(this._link.href):n.open(this._link.href,{allowCommands:!0}))}))),this.enabled=!0}setTooltip(e){this.hoverDelegate.showNativeHover?this.el.title=e??"":!this.hover&&e?this.hover=this._register(this._hoverService.setupManagedHover(this.hoverDelegate,this.el,e)):this.hover&&this.hover.update(e)}};I=A([N(3,k.TN),N(4,T.C)],I);var O=i(61394),D=i(25689),M=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},P=function(e,t){return function(i,s){t(i,s,e)}};let F=class extends o.jG{constructor(e,t){super(),this._editor=e,this.instantiationService=t,this.banner=this._register(this.instantiationService.createInstance(U))}hide(){this._editor.setBanner(null,0),this.banner.clear()}show(e){this.banner.show({...e,onClose:()=>{this.hide(),e.onClose?.()}}),this._editor.setBanner(this.banner.element,26)}};F=M([P(1,S._Y)],F);let U=class extends o.jG{constructor(e){super(),this.instantiationService=e,this.markdownRenderer=this.instantiationService.createInstance(E.T,{}),this.element=(0,v.$)("div.editor-banner"),this.element.tabIndex=0}getAriaLabel(e){return e.ariaLabel?e.ariaLabel:"string"===typeof e.message?e.message:void 0}getBannerMessage(e){if("string"===typeof e){const t=(0,v.$)("span");return t.innerText=e,t}return this.markdownRenderer.render(e).element}clear(){(0,v.w_)(this.element)}show(e){(0,v.w_)(this.element);const t=this.getAriaLabel(e);t&&this.element.setAttribute("aria-label",t);const i=(0,v.BC)(this.element,(0,v.$)("div.icon-container"));i.setAttribute("aria-hidden","true"),e.icon&&i.appendChild((0,v.$)(`div${D.L.asCSSSelector(e.icon)}`));const s=(0,v.BC)(this.element,(0,v.$)("div.message-container"));if(s.setAttribute("aria-hidden","true"),s.appendChild(this.getBannerMessage(e.message)),this.messageActionsContainer=(0,v.BC)(this.element,(0,v.$)("div.message-actions-container")),e.actions)for(const r of e.actions)this._register(this.instantiationService.createInstance(I,this.messageActionsContainer,{...r,tabIndex:-1},{}));const n=(0,v.BC)(this.element,(0,v.$)("div.action-container"));this.actionBar=this._register(new C.E(n)),this.actionBar.push(this._register(new b.rc("banner.close","Close Banner",D.L.asClassName(O.$_),!0,(()=>{"function"===typeof e.onClose&&e.onClose()}))),{icon:!0,label:!1}),this.actionBar.setFocusable(!1)}};U=M([P(0,S._Y)],U);var H=i(78209),B=i(84001),W=i(51467),V=i(51465),z=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},G=function(e,t){return function(i,s){t(i,s,e)}};const j=(0,O.pU)("extensions-warning-message",n.W.warning,H.kg("warningIcon","Icon shown with a warning message in the extensions editor."));let K=class extends o.jG{static{this.ID="editor.contrib.unicodeHighlighter"}constructor(e,t,i,s){super(),this._editor=e,this._editorWorkerService=t,this._workspaceTrustService=i,this._highlighter=null,this._bannerClosed=!1,this._updateState=e=>{if(e&&e.hasMore){if(this._bannerClosed)return;const t=Math.max(e.ambiguousCharacterCount,e.nonBasicAsciiCharacterCount,e.invisibleCharacterCount);let i;if(e.nonBasicAsciiCharacterCount>=t)i={message:H.kg("unicodeHighlighting.thisDocumentHasManyNonBasicAsciiUnicodeCharacters","This document contains many non-basic ASCII unicode characters"),command:new re};else if(e.ambiguousCharacterCount>=t)i={message:H.kg("unicodeHighlighting.thisDocumentHasManyAmbiguousUnicodeCharacters","This document contains many ambiguous unicode characters"),command:new se};else{if(!(e.invisibleCharacterCount>=t))throw new Error("Unreachable");i={message:H.kg("unicodeHighlighting.thisDocumentHasManyInvisibleUnicodeCharacters","This document contains many invisible unicode characters"),command:new ne}}this._bannerController.show({id:"unicodeHighlightBanner",message:i.message,icon:j,actions:[{label:i.command.shortLabel,href:`command:${i.command.id}`}],onClose:()=>{this._bannerClosed=!0}})}else this._bannerController.hide()},this._bannerController=this._register(s.createInstance(F,e)),this._register(this._editor.onDidChangeModel((()=>{this._bannerClosed=!1,this._updateHighlighter()}))),this._options=e.getOption(126),this._register(i.onDidChangeTrust((e=>{this._updateHighlighter()}))),this._register(e.onDidChangeConfiguration((t=>{t.hasChanged(126)&&(this._options=e.getOption(126),this._updateHighlighter())}))),this._updateHighlighter()}dispose(){this._highlighter&&(this._highlighter.dispose(),this._highlighter=null),super.dispose()}_updateHighlighter(){if(this._updateState(null),this._highlighter&&(this._highlighter.dispose(),this._highlighter=null),!this._editor.hasModel())return;const e=function(e,t){return{nonBasicASCII:t.nonBasicASCII===h.XR?!e:t.nonBasicASCII,ambiguousCharacters:t.ambiguousCharacters,invisibleCharacters:t.invisibleCharacters,includeComments:t.includeComments===h.XR?!e:t.includeComments,includeStrings:t.includeStrings===h.XR?!e:t.includeStrings,allowedCharacters:t.allowedCharacters,allowedLocales:t.allowedLocales}}(this._workspaceTrustService.isWorkspaceTrusted(),this._options);if([e.nonBasicASCII,e.ambiguousCharacters,e.invisibleCharacters].every((e=>!1===e)))return;const t={nonBasicASCII:e.nonBasicASCII,ambiguousCharacters:e.ambiguousCharacters,invisibleCharacters:e.invisibleCharacters,includeComments:e.includeComments,includeStrings:e.includeStrings,allowedCodePoints:Object.keys(e.allowedCharacters).map((e=>e.codePointAt(0))),allowedLocales:Object.keys(e.allowedLocales).map((e=>{if("_os"===e){return(new Intl.NumberFormat).resolvedOptions().locale}return"_vscode"===e?a.BH:e}))};this._editorWorkerService.canComputeUnicodeHighlights(this._editor.getModel().uri)?this._highlighter=new Y(this._editor,t,this._updateState,this._editorWorkerService):this._highlighter=new q(this._editor,t,this._updateState)}getDecorationInfo(e){return this._highlighter?this._highlighter.getDecorationInfo(e):null}};K=z([G(1,g.IEditorWorkerService),G(2,V.L),G(3,S._Y)],K);let Y=class extends o.jG{constructor(e,t,i,n){super(),this._editor=e,this._options=t,this._updateState=i,this._editorWorkerService=n,this._model=this._editor.getModel(),this._decorations=this._editor.createDecorationsCollection(),this._updateSoon=this._register(new s.uC((()=>this._update()),250)),this._register(this._editor.onDidChangeModelContent((()=>{this._updateSoon.schedule()}))),this._updateSoon.schedule()}dispose(){this._decorations.clear(),super.dispose()}_update(){if(this._model.isDisposed())return;if(!this._model.mightContainNonBasicASCII())return void this._decorations.clear();const e=this._model.getVersionId();this._editorWorkerService.computedUnicodeHighlights(this._model.uri,this._options).then((t=>{if(this._model.isDisposed())return;if(this._model.getVersionId()!==e)return;this._updateState(t);const i=[];if(!t.hasMore)for(const e of t.ranges)i.push({range:e,options:ee.instance.getDecorationFromOptions(this._options)});this._decorations.set(i)}))}getDecorationInfo(e){if(!this._decorations.has(e))return null;const t=this._editor.getModel();if(!(0,m.GN)(t,e))return null;return{reason:J(t.getValueInRange(e.range),this._options),inComment:(0,m.a6)(t,e),inString:(0,m.wc)(t,e)}}};Y=z([G(3,g.IEditorWorkerService)],Y);class q extends o.jG{constructor(e,t,i){super(),this._editor=e,this._options=t,this._updateState=i,this._model=this._editor.getModel(),this._decorations=this._editor.createDecorationsCollection(),this._updateSoon=this._register(new s.uC((()=>this._update()),250)),this._register(this._editor.onDidLayoutChange((()=>{this._updateSoon.schedule()}))),this._register(this._editor.onDidScrollChange((()=>{this._updateSoon.schedule()}))),this._register(this._editor.onDidChangeHiddenAreas((()=>{this._updateSoon.schedule()}))),this._register(this._editor.onDidChangeModelContent((()=>{this._updateSoon.schedule()}))),this._updateSoon.schedule()}dispose(){this._decorations.clear(),super.dispose()}_update(){if(this._model.isDisposed())return;if(!this._model.mightContainNonBasicASCII())return void this._decorations.clear();const e=this._editor.getVisibleRanges(),t=[],i={ranges:[],ambiguousCharacterCount:0,invisibleCharacterCount:0,nonBasicAsciiCharacterCount:0,hasMore:!1};for(const s of e){const e=u.UnicodeTextModelHighlighter.computeUnicodeHighlights(this._model,this._options,s);for(const t of e.ranges)i.ranges.push(t);i.ambiguousCharacterCount+=i.ambiguousCharacterCount,i.invisibleCharacterCount+=i.invisibleCharacterCount,i.nonBasicAsciiCharacterCount+=i.nonBasicAsciiCharacterCount,i.hasMore=i.hasMore||e.hasMore}if(!i.hasMore)for(const s of i.ranges)t.push({range:s,options:ee.instance.getDecorationFromOptions(this._options)});this._updateState(i),this._decorations.set(t)}getDecorationInfo(e){if(!this._decorations.has(e))return null;const t=this._editor.getModel(),i=t.getValueInRange(e.range);return(0,m.GN)(t,e)?{reason:J(i,this._options),inComment:(0,m.a6)(t,e),inString:(0,m.wc)(t,e)}:null}}const $=H.kg("unicodeHighlight.configureUnicodeHighlightOptions","Configure Unicode Highlight Options");let Q=class{constructor(e,t,i){this._editor=e,this._languageService=t,this._openerService=i,this.hoverOrdinal=5}computeSync(e,t){if(!this._editor.hasModel()||1!==e.type)return[];const i=this._editor.getModel(),s=this._editor.getContribution(K.ID);if(!s)return[];const n=[],o=new Set;let a=300;for(const c of t){const e=s.getDecorationInfo(c);if(!e)continue;const t=i.getValueInRange(c.range).codePointAt(0),h=Z(t);let d;switch(e.reason.kind){case 0:d=(0,l.aC)(e.reason.confusableWith)?H.kg("unicodeHighlight.characterIsAmbiguousASCII","The character {0} could be confused with the ASCII character {1}, which is more common in source code.",h,Z(e.reason.confusableWith.codePointAt(0))):H.kg("unicodeHighlight.characterIsAmbiguous","The character {0} could be confused with the character {1}, which is more common in source code.",h,Z(e.reason.confusableWith.codePointAt(0)));break;case 1:d=H.kg("unicodeHighlight.characterIsInvisible","The character {0} is invisible.",h);break;case 2:d=H.kg("unicodeHighlight.characterIsNonBasicAscii","The character {0} is not a basic ASCII character.",h)}if(o.has(d))continue;o.add(d);const u={codePoint:t,reason:e.reason,inComment:e.inComment,inString:e.inString},g=H.kg("unicodeHighlight.adjustSettings","Adjust settings"),p=`command:${oe.ID}?${encodeURIComponent(JSON.stringify(u))}`,m=new r.Bc("",!0).appendMarkdown(d).appendText(" ").appendLink(p,g,$);n.push(new _.eH(this,c.range,[m],!1,a++))}return n}renderHoverParts(e,t){return(0,_.fm)(e,t,this._editor,this._languageService,this._openerService)}};function X(e){return`U+${e.toString(16).padStart(4,"0")}`}function Z(e){let t=`\`${X(e)}\``;return l.y_.isInvisibleCharacter(e)||(t+=` "${function(e){if(96===e)return"`` ` ``";return"`"+String.fromCodePoint(e)+"`"}(e)}"`),t}function J(e,t){return u.UnicodeTextModelHighlighter.computeUnicodeHighlightReason(e,t)}Q=z([G(1,p.L),G(2,T.C)],Q);class ee{constructor(){this.map=new Map}static{this.instance=new ee}getDecorationFromOptions(e){return this.getDecoration(!e.includeComments,!e.includeStrings)}getDecoration(e,t){const i=`${e}${t}`;let s=this.map.get(i);return s||(s=d.kI.createDynamic({description:"unicode-highlight",stickiness:1,className:"unicode-highlight",showIfCollapsed:!0,overviewRuler:null,minimap:null,hideInCommentTokens:e,hideInStringTokens:t}),this.map.set(i,s)),s}}class te extends c.ks{constructor(){super({id:se.ID,label:H.kg("action.unicodeHighlight.disableHighlightingInComments","Disable highlighting of characters in comments"),alias:"Disable highlighting of characters in comments",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingInComments.shortLabel","Disable Highlight In Comments")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.includeComments,!1,2)}}class ie extends c.ks{constructor(){super({id:se.ID,label:H.kg("action.unicodeHighlight.disableHighlightingInStrings","Disable highlighting of characters in strings"),alias:"Disable highlighting of characters in strings",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingInStrings.shortLabel","Disable Highlight In Strings")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.includeStrings,!1,2)}}class se extends c.ks{static{this.ID="editor.action.unicodeHighlight.disableHighlightingOfAmbiguousCharacters"}constructor(){super({id:se.ID,label:H.kg("action.unicodeHighlight.disableHighlightingOfAmbiguousCharacters","Disable highlighting of ambiguous characters"),alias:"Disable highlighting of ambiguous characters",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingOfAmbiguousCharacters.shortLabel","Disable Ambiguous Highlight")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.ambiguousCharacters,!1,2)}}class ne extends c.ks{static{this.ID="editor.action.unicodeHighlight.disableHighlightingOfInvisibleCharacters"}constructor(){super({id:ne.ID,label:H.kg("action.unicodeHighlight.disableHighlightingOfInvisibleCharacters","Disable highlighting of invisible characters"),alias:"Disable highlighting of invisible characters",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingOfInvisibleCharacters.shortLabel","Disable Invisible Highlight")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.invisibleCharacters,!1,2)}}class re extends c.ks{static{this.ID="editor.action.unicodeHighlight.disableHighlightingOfNonBasicAsciiCharacters"}constructor(){super({id:re.ID,label:H.kg("action.unicodeHighlight.disableHighlightingOfNonBasicAsciiCharacters","Disable highlighting of non basic ASCII characters"),alias:"Disable highlighting of non basic ASCII characters",precondition:void 0}),this.shortLabel=H.kg("unicodeHighlight.disableHighlightingOfNonBasicAsciiCharacters.shortLabel","Disable Non ASCII Highlight")}async run(e,t,i){const s=e?.get(B.pG);s&&this.runAction(s)}async runAction(e){await e.updateValue(h.Of.nonBasicASCII,!1,2)}}class oe extends c.ks{static{this.ID="editor.action.unicodeHighlight.showExcludeOptions"}constructor(){super({id:oe.ID,label:H.kg("action.unicodeHighlight.showExcludeOptions","Show Exclude Options"),alias:"Show Exclude Options",precondition:void 0})}async run(e,t,i){const{codePoint:s,reason:n,inString:r,inComment:o}=i,a=String.fromCodePoint(s),c=e.get(W.GK),d=e.get(B.pG);const u=[];if(0===n.kind)for(const l of n.notAmbiguousInLocales)u.push({label:H.kg("unicodeHighlight.allowCommonCharactersInLanguage",'Allow unicode characters that are more common in the language "{0}".',l),run:async()=>{ae(d,[l])}});if(u.push({label:function(e){return l.y_.isInvisibleCharacter(e)?H.kg("unicodeHighlight.excludeInvisibleCharFromBeingHighlighted","Exclude {0} (invisible character) from being highlighted",X(e)):H.kg("unicodeHighlight.excludeCharFromBeingHighlighted","Exclude {0} from being highlighted",`${X(e)} "${a}"`)}(s),run:()=>async function(e,t){const i=e.getValue(h.Of.allowedCharacters);let s;s="object"===typeof i&&i?i:{};for(const n of t)s[String.fromCodePoint(n)]=!0;await e.updateValue(h.Of.allowedCharacters,s,2)}(d,[s])}),o){const e=new te;u.push({label:e.label,run:async()=>e.runAction(d)})}else if(r){const e=new ie;u.push({label:e.label,run:async()=>e.runAction(d)})}if(0===n.kind){const e=new se;u.push({label:e.label,run:async()=>e.runAction(d)})}else if(1===n.kind){const e=new ne;u.push({label:e.label,run:async()=>e.runAction(d)})}else if(2===n.kind){const e=new re;u.push({label:e.label,run:async()=>e.runAction(d)})}else!function(e){throw new Error(`Unexpected value: ${e}`)}(n);const g=await c.pick(u,{title:$});g&&await g.run()}}async function ae(e,t){const i=e.inspect(h.Of.allowedLocales).user?.value;let s;s="object"===typeof i&&i?Object.assign({},i):{};for(const n of t)s[n]=!0;await e.updateValue(h.Of.allowedLocales,s,2)}(0,c.Fl)(se),(0,c.Fl)(ne),(0,c.Fl)(re),(0,c.Fl)(oe),(0,c.HW)(K.ID,K,1),f.B2.register(Q)},47210:(e,t,i)=>{"use strict";var s=i(5662),n=i(89403),r=i(31450),o=i(80301),a=i(78209),l=i(59599),c=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},h=function(e,t){return function(i,s){t(i,s,e)}};const d="ignoreUnusualLineTerminators";let u=class extends s.jG{static{this.ID="editor.contrib.unusualLineTerminatorsDetector"}constructor(e,t,i){super(),this._editor=e,this._dialogService=t,this._codeEditorService=i,this._isPresentingDialog=!1,this._config=this._editor.getOption(127),this._register(this._editor.onDidChangeConfiguration((e=>{e.hasChanged(127)&&(this._config=this._editor.getOption(127),this._checkForUnusualLineTerminators())}))),this._register(this._editor.onDidChangeModel((()=>{this._checkForUnusualLineTerminators()}))),this._register(this._editor.onDidChangeModelContent((e=>{e.isUndoing||this._checkForUnusualLineTerminators()}))),this._checkForUnusualLineTerminators()}async _checkForUnusualLineTerminators(){if("off"===this._config)return;if(!this._editor.hasModel())return;const e=this._editor.getModel();if(!e.mightContainUnusualLineTerminators())return;const t=function(e,t){return e.getModelProperty(t.uri,d)}(this._codeEditorService,e);if(!0===t)return;if(this._editor.getOption(92))return;if("auto"===this._config)return void e.removeUnusualLineTerminators(this._editor.getSelections());if(this._isPresentingDialog)return;let i;try{this._isPresentingDialog=!0,i=await this._dialogService.confirm({title:a.kg("unusualLineTerminators.title","Unusual Line Terminators"),message:a.kg("unusualLineTerminators.message","Detected unusual line terminators"),detail:a.kg("unusualLineTerminators.detail","The file '{0}' contains one or more unusual line terminator characters, like Line Separator (LS) or Paragraph Separator (PS).\n\nIt is recommended to remove them from the file. This can be configured via `editor.unusualLineTerminators`.",(0,n.P8)(e.uri)),primaryButton:a.kg({key:"unusualLineTerminators.fix",comment:["&& denotes a mnemonic"]},"&&Remove Unusual Line Terminators"),cancelButton:a.kg("unusualLineTerminators.ignore","Ignore")})}finally{this._isPresentingDialog=!1}i.confirmed?e.removeUnusualLineTerminators(this._editor.getSelections()):function(e,t,i){e.setModelProperty(t.uri,d,i)}(this._codeEditorService,e,!0)}};u=c([h(1,l.X),h(2,o.T)],u),(0,r.HW)(u.ID,u,1)},13864:(e,t,i)=>{"use strict";i.d(t,{P:()=>C,v:()=>b});var s=i(16223),n=i(87289),r=i(62083),o=i(78209),a=i(66261),l=i(47612);const c=(0,a.x1A)("editor.wordHighlightBackground",{dark:"#575757B8",light:"#57575740",hcDark:null,hcLight:null},o.kg("wordHighlight","Background color of a symbol during read-access, like reading a variable. The color must not be opaque so as not to hide underlying decorations."),!0);(0,a.x1A)("editor.wordHighlightStrongBackground",{dark:"#004972B8",light:"#0e639c40",hcDark:null,hcLight:null},o.kg("wordHighlightStrong","Background color of a symbol during write-access, like writing to a variable. The color must not be opaque so as not to hide underlying decorations."),!0),(0,a.x1A)("editor.wordHighlightTextBackground",c,o.kg("wordHighlightText","Background color of a textual occurrence for a symbol. The color must not be opaque so as not to hide underlying decorations."),!0);const h=(0,a.x1A)("editor.wordHighlightBorder",{light:null,dark:null,hcDark:a.buw,hcLight:a.buw},o.kg("wordHighlightBorder","Border color of a symbol during read-access, like reading a variable."));(0,a.x1A)("editor.wordHighlightStrongBorder",{light:null,dark:null,hcDark:a.buw,hcLight:a.buw},o.kg("wordHighlightStrongBorder","Border color of a symbol during write-access, like writing to a variable.")),(0,a.x1A)("editor.wordHighlightTextBorder",h,o.kg("wordHighlightTextBorder","Border color of a textual occurrence for a symbol."));const d=(0,a.x1A)("editorOverviewRuler.wordHighlightForeground","#A0A0A0CC",o.kg("overviewRulerWordHighlightForeground","Overview ruler marker color for symbol highlights. The color must not be opaque so as not to hide underlying decorations."),!0),u=(0,a.x1A)("editorOverviewRuler.wordHighlightStrongForeground","#C0A0C0CC",o.kg("overviewRulerWordHighlightStrongForeground","Overview ruler marker color for write-access symbol highlights. The color must not be opaque so as not to hide underlying decorations."),!0),g=(0,a.x1A)("editorOverviewRuler.wordHighlightTextForeground",a.z5H,o.kg("overviewRulerWordHighlightTextForeground","Overview ruler marker color of a textual occurrence for a symbol. The color must not be opaque so as not to hide underlying decorations."),!0),p=n.kI.register({description:"word-highlight-strong",stickiness:1,className:"wordHighlightStrong",overviewRuler:{color:(0,l.Yf)(u),position:s.A5.Center},minimap:{color:(0,l.Yf)(a.Xp1),position:1}}),m=n.kI.register({description:"word-highlight-text",stickiness:1,className:"wordHighlightText",overviewRuler:{color:(0,l.Yf)(g),position:s.A5.Center},minimap:{color:(0,l.Yf)(a.Xp1),position:1}}),f=n.kI.register({description:"selection-highlight-overview",stickiness:1,className:"selectionHighlight",overviewRuler:{color:(0,l.Yf)(a.z5H),position:s.A5.Center},minimap:{color:(0,l.Yf)(a.Xp1),position:1}}),_=n.kI.register({description:"selection-highlight",stickiness:1,className:"selectionHighlight"}),v=n.kI.register({description:"word-highlight",stickiness:1,className:"wordHighlight",overviewRuler:{color:(0,l.Yf)(d),position:s.A5.Center},minimap:{color:(0,l.Yf)(a.Xp1),position:1}});function C(e){return e===r.Kb.Write?p:e===r.Kb.Text?m:v}function b(e){return e?_:f}(0,l.zy)(((e,t)=>{const i=e.getColor(a.QwA);i&&t.addRule(`.monaco-editor .selectionHighlight { background-color: ${i.transparent(.5)}; }`)}))},79907:(e,t,i)=>{"use strict";var s=i(78209),n=i(11007),r=i(90766),o=i(18447),a=i(64383),l=i(5662),c=i(34326),h=i(31450),d=i(80301),u=i(36677),g=i(60002),p=i(16223),m=i(56942),f=i(13864),_=i(32848),v=i(36456),C=i(74320),b=i(54459),E=i(89403),S=i(26486),y=i(62083),w=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},L=function(e,t){return function(i,s){t(i,s,e)}};class R{constructor(){this.selector={language:"*"}}provideDocumentHighlights(e,t,i){const s=[],n=e.getWordAtPosition({lineNumber:t.lineNumber,column:t.column});if(!n)return Promise.resolve(s);if(e.isDisposed())return;return e.findMatches(n.word,!0,!1,!0,S.J3,!1).map((e=>({range:e.range,kind:y.Kb.Text})))}provideMultiDocumentHighlights(e,t,i,s){const n=new C.fT,r=e.getWordAtPosition({lineNumber:t.lineNumber,column:t.column});if(!r)return Promise.resolve(n);for(const o of[e,...i]){if(o.isDisposed())continue;const e=o.findMatches(r.word,!0,!1,!0,S.J3,!1).map((e=>({range:e.range,kind:y.Kb.Text})));e&&n.set(o.uri,e)}return n}}let T=class extends l.jG{constructor(e){super(),this._register(e.documentHighlightProvider.register("*",new R)),this._register(e.multiDocumentHighlightProvider.register("*",new R))}};T=w([L(0,m.ILanguageFeaturesService)],T);var x,k,A=i(72466),N=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},I=function(e,t){return function(i,s){t(i,s,e)}};const O=new _.N1("hasWordHighlights",!1);function D(e,t,i,s){const n=e.ordered(t);return(0,r.$1)(n.map((e=>()=>Promise.resolve(e.provideDocumentHighlights(t,i,s)).then(void 0,a.M_))),(e=>void 0!==e&&null!==e)).then((e=>{if(e){const i=new C.fT;return i.set(t.uri,e),i}return new C.fT}))}class M{constructor(e,t,i){this._model=e,this._selection=t,this._wordSeparators=i,this._wordRange=this._getCurrentWordRange(e,t),this._result=null}get result(){return this._result||(this._result=(0,r.SS)((e=>this._compute(this._model,this._selection,this._wordSeparators,e)))),this._result}_getCurrentWordRange(e,t){const i=e.getWordAtPosition(t.getPosition());return i?new u.Q(t.startLineNumber,i.startColumn,t.startLineNumber,i.endColumn):null}isValid(e,t,i){const s=t.startLineNumber,n=t.startColumn,r=t.endColumn,o=this._getCurrentWordRange(e,t);let a=Boolean(this._wordRange&&this._wordRange.equalsRange(o));for(let l=0,c=i.length;!a&&l=r&&(a=!0)}return a}cancel(){this.result.cancel()}}class P extends M{constructor(e,t,i,s){super(e,t,i),this._providers=s}_compute(e,t,i,s){return D(this._providers,e,t.getPosition(),s).then((e=>e||new C.fT))}}class F extends M{constructor(e,t,i,s,n){super(e,t,i),this._providers=s,this._otherModels=n}_compute(e,t,i,s){return function(e,t,i,s,n,o){const l=e.ordered(t);return(0,r.$1)(l.map((e=>()=>{const s=o.filter((e=>(0,p.vd)(e))).filter((t=>(0,b.f)(e.selector,t.uri,t.getLanguageId(),!0,void 0,void 0)>0));return Promise.resolve(e.provideMultiDocumentHighlights(t,i,s,n)).then(void 0,a.M_)})),(e=>void 0!==e&&null!==e))}(this._providers,e,t.getPosition(),0,s,this._otherModels).then((e=>e||new C.fT))}}(0,h.ke)("_executeDocumentHighlights",(async(e,t,i)=>{const s=e.get(m.ILanguageFeaturesService),n=await D(s.documentHighlightProvider,t,i,o.XO.None);return n?.get(t.uri)}));let U=class{static{x=this}static{this.storedDecorationIDs=new C.fT}static{this.query=null}constructor(e,t,i,s,n){this.toUnhook=new l.Cm,this.workerRequestTokenId=0,this.workerRequestCompleted=!1,this.workerRequestValue=new C.fT,this.lastCursorPositionChangeTime=0,this.renderDecorationsTimer=-1,this.runDelayer=this.toUnhook.add(new r.ve(50)),this.editor=e,this.providers=t,this.multiDocumentProviders=i,this.codeEditorService=n,this._hasWordHighlights=O.bindTo(s),this._ignorePositionChangeEvent=!1,this.occurrencesHighlight=this.editor.getOption(81),this.model=this.editor.getModel(),this.toUnhook.add(e.onDidChangeCursorPosition((e=>{this._ignorePositionChangeEvent||"off"!==this.occurrencesHighlight&&this.runDelayer.trigger((()=>{this._onPositionChanged(e)}))}))),this.toUnhook.add(e.onDidFocusEditorText((e=>{"off"!==this.occurrencesHighlight&&(this.workerRequest||this.runDelayer.trigger((()=>{this._run()})))}))),this.toUnhook.add(e.onDidChangeModelContent((e=>{(0,v.v$)(this.model.uri,"output")||this._stopAll()}))),this.toUnhook.add(e.onDidChangeModel((e=>{!e.newModelUrl&&e.oldModelUrl?this._stopSingular():x.query&&this._run()}))),this.toUnhook.add(e.onDidChangeConfiguration((e=>{const t=this.editor.getOption(81);if(this.occurrencesHighlight!==t)switch(this.occurrencesHighlight=t,t){case"off":this._stopAll();break;case"singleFile":this._stopAll(x.query?.modelInfo?.model);break;case"multiFile":x.query&&this._run(!0);break;default:console.warn("Unknown occurrencesHighlight setting value:",t)}}))),this.decorations=this.editor.createDecorationsCollection(),this.workerRequestTokenId=0,this.workerRequest=null,this.workerRequestCompleted=!1,this.lastCursorPositionChangeTime=0,this.renderDecorationsTimer=-1,x.query&&this._run()}hasDecorations(){return this.decorations.length>0}restore(){"off"!==this.occurrencesHighlight&&(this.runDelayer.cancel(),this._run())}_getSortedHighlights(){return this.decorations.getRanges().sort(u.Q.compareRangesUsingStarts)}moveNext(){const e=this._getSortedHighlights(),t=e.findIndex((e=>e.containsPosition(this.editor.getPosition()))),i=(t+1)%e.length,s=e[i];try{this._ignorePositionChangeEvent=!0,this.editor.setPosition(s.getStartPosition()),this.editor.revealRangeInCenterIfOutsideViewport(s);const t=this._getWord();if(t){const r=this.editor.getModel().getLineContent(s.startLineNumber);(0,n.xE)(`${r}, ${i+1} of ${e.length} for '${t.word}'`)}}finally{this._ignorePositionChangeEvent=!1}}moveBack(){const e=this._getSortedHighlights(),t=e.findIndex((e=>e.containsPosition(this.editor.getPosition()))),i=(t-1+e.length)%e.length,s=e[i];try{this._ignorePositionChangeEvent=!0,this.editor.setPosition(s.getStartPosition()),this.editor.revealRangeInCenterIfOutsideViewport(s);const t=this._getWord();if(t){const r=this.editor.getModel().getLineContent(s.startLineNumber);(0,n.xE)(`${r}, ${i+1} of ${e.length} for '${t.word}'`)}}finally{this._ignorePositionChangeEvent=!1}}_removeSingleDecorations(){if(!this.editor.hasModel())return;const e=x.storedDecorationIDs.get(this.editor.getModel().uri);e&&(this.editor.removeDecorations(e),x.storedDecorationIDs.delete(this.editor.getModel().uri),this.decorations.length>0&&(this.decorations.clear(),this._hasWordHighlights.set(!1)))}_removeAllDecorations(e){const t=this.codeEditorService.listCodeEditors(),i=[];for(const s of t){if(!s.hasModel()||(0,E.n4)(s.getModel().uri,e?.uri))continue;const t=x.storedDecorationIDs.get(s.getModel().uri);if(!t)continue;s.removeDecorations(t),i.push(s.getModel().uri);const n=H.get(s);n?.wordHighlighter&&(n.wordHighlighter.decorations.length>0&&(n.wordHighlighter.decorations.clear(),n.wordHighlighter.workerRequest=null,n.wordHighlighter._hasWordHighlights.set(!1)))}for(const s of i)x.storedDecorationIDs.delete(s)}_stopSingular(){this._removeSingleDecorations(),this.editor.hasTextFocus()&&(this.editor.getModel()?.uri.scheme!==v.ny.vscodeNotebookCell&&x.query?.modelInfo?.model.uri.scheme!==v.ny.vscodeNotebookCell?(x.query=null,this._run()):x.query?.modelInfo&&(x.query.modelInfo=null)),-1!==this.renderDecorationsTimer&&(clearTimeout(this.renderDecorationsTimer),this.renderDecorationsTimer=-1),null!==this.workerRequest&&(this.workerRequest.cancel(),this.workerRequest=null),this.workerRequestCompleted||(this.workerRequestTokenId++,this.workerRequestCompleted=!0)}_stopAll(e){this._removeAllDecorations(e),-1!==this.renderDecorationsTimer&&(clearTimeout(this.renderDecorationsTimer),this.renderDecorationsTimer=-1),null!==this.workerRequest&&(this.workerRequest.cancel(),this.workerRequest=null),this.workerRequestCompleted||(this.workerRequestTokenId++,this.workerRequestCompleted=!0)}_onPositionChanged(e){"off"!==this.occurrencesHighlight&&(3===e.reason||this.editor.getModel()?.uri.scheme===v.ny.vscodeNotebookCell)?this._run():this._stopAll()}_getWord(){const e=this.editor.getSelection(),t=e.startLineNumber,i=e.startColumn;return this.model.isDisposed()?null:this.model.getWordAtPosition({lineNumber:t,column:i})}getOtherModelsToHighlight(e){if(!e)return[];if(e.uri.scheme===v.ny.vscodeNotebookCell){const t=[],i=this.codeEditorService.listCodeEditors();for(const s of i){const i=s.getModel();i&&i!==e&&i.uri.scheme===v.ny.vscodeNotebookCell&&t.push(i)}return t}const t=[],i=this.codeEditorService.listCodeEditors();for(const s of i){if(!(0,c.Np)(s))continue;const i=s.getModel();i&&(e===i.modified&&t.push(i.modified))}if(t.length)return t;if("singleFile"===this.occurrencesHighlight)return[];for(const s of i){const i=s.getModel();i&&i!==e&&t.push(i)}return t}_run(e){let t;if(this.editor.hasTextFocus()){const e=this.editor.getSelection();if(!e||e.startLineNumber!==e.endLineNumber)return x.query=null,void this._stopAll();const i=e.startColumn,s=e.endColumn,n=this._getWord();if(!n||n.startColumn>i||n.endColumn{t===this.workerRequestTokenId&&(this.workerRequestCompleted=!0,this.workerRequestValue=e||[],this._beginRenderDecorations())}),a.dz)}}computeWithModel(e,t,i,s){return s.length?function(e,t,i,s,n,r){return new F(t,i,n,e,r)}(this.multiDocumentProviders,e,t,0,this.editor.getOption(132),s):function(e,t,i,s,n){return new P(t,i,n,e)}(this.providers,e,t,0,this.editor.getOption(132))}_beginRenderDecorations(){const e=(new Date).getTime(),t=this.lastCursorPositionChangeTime+250;e>=t?(this.renderDecorationsTimer=-1,this.renderDecorations()):this.renderDecorationsTimer=setTimeout((()=>{this.renderDecorations()}),t-e)}renderDecorations(){this.renderDecorationsTimer=-1;const e=this.codeEditorService.listCodeEditors();for(const t of e){const e=H.get(t);if(!e)continue;const i=[],s=t.getModel()?.uri;if(s&&this.workerRequestValue.has(s)){const n=x.storedDecorationIDs.get(s),r=this.workerRequestValue.get(s);if(r)for(const e of r)e.range&&i.push({range:e.range,options:(0,f.P)(e.kind)});let o=[];t.changeDecorations((e=>{o=e.deltaDecorations(n??[],i)})),x.storedDecorationIDs=x.storedDecorationIDs.set(s,o),i.length>0&&(e.wordHighlighter?.decorations.set(i),e.wordHighlighter?._hasWordHighlights.set(!0))}}}dispose(){this._stopSingular(),this.toUnhook.dispose()}};U=x=N([I(4,d.T)],U);let H=class extends l.jG{static{k=this}static{this.ID="editor.contrib.wordHighlighter"}static get(e){return e.getContribution(k.ID)}constructor(e,t,i,s){super(),this._wordHighlighter=null;const n=()=>{e.hasModel()&&!e.getModel().isTooLargeForTokenization()&&(this._wordHighlighter=new U(e,i.documentHighlightProvider,i.multiDocumentHighlightProvider,t,s))};this._register(e.onDidChangeModel((e=>{this._wordHighlighter&&(this._wordHighlighter.dispose(),this._wordHighlighter=null),n()}))),n()}get wordHighlighter(){return this._wordHighlighter}saveViewState(){return!(!this._wordHighlighter||!this._wordHighlighter.hasDecorations())}moveNext(){this._wordHighlighter?.moveNext()}moveBack(){this._wordHighlighter?.moveBack()}restoreViewState(e){this._wordHighlighter&&e&&this._wordHighlighter.restore()}dispose(){this._wordHighlighter&&(this._wordHighlighter.dispose(),this._wordHighlighter=null),super.dispose()}};H=k=N([I(1,_.fN),I(2,m.ILanguageFeaturesService),I(3,d.T)],H);class B extends h.ks{constructor(e,t){super(t),this._isNext=e}run(e,t){const i=H.get(t);i&&(this._isNext?i.moveNext():i.moveBack())}}class W extends h.ks{constructor(){super({id:"editor.action.wordHighlight.trigger",label:s.kg("wordHighlight.trigger.label","Trigger Symbol Highlight"),alias:"Trigger Symbol Highlight",precondition:void 0,kbOpts:{kbExpr:g.R.editorTextFocus,primary:0,weight:100}})}run(e,t,i){const s=H.get(t);s&&s.restoreViewState(!0)}}(0,h.HW)(H.ID,H,0),(0,h.Fl)(class extends B{constructor(){super(!0,{id:"editor.action.wordHighlight.next",label:s.kg("wordHighlight.next.label","Go to Next Symbol Highlight"),alias:"Go to Next Symbol Highlight",precondition:O,kbOpts:{kbExpr:g.R.editorTextFocus,primary:65,weight:100}})}}),(0,h.Fl)(class extends B{constructor(){super(!1,{id:"editor.action.wordHighlight.prev",label:s.kg("wordHighlight.previous.label","Go to Previous Symbol Highlight"),alias:"Go to Previous Symbol Highlight",precondition:O,kbOpts:{kbExpr:g.R.editorTextFocus,primary:1089,weight:100}})}}),(0,h.Fl)(W),(0,A.x)(T)},38728:(e,t,i)=>{"use strict";i.d(t,{Jk:()=>v,R7:()=>E});var s=i(31450),n=i(15092),r=i(87908),o=i(32799),a=i(97681),l=i(81782),c=i(83069),h=i(36677),d=i(75326),u=i(60002),g=i(17469),p=i(78209),m=i(253),f=i(32848),_=i(28290);class v extends s.DX{constructor(e){super(e),this._inSelectionMode=e.inSelectionMode,this._wordNavigationType=e.wordNavigationType}runEditorCommand(e,t,i){if(!t.hasModel())return;const s=(0,l.i)(t.getOption(132),t.getOption(131)),n=t.getModel(),r=t.getSelections(),a=r.length>1,h=r.map((e=>{const t=new c.y(e.positionLineNumber,e.positionColumn),i=this._move(s,n,t,this._wordNavigationType,a);return this._moveTo(e,i,this._inSelectionMode)}));if(n.pushStackElement(),t._getViewModel().setCursorStates("moveWordCommand",3,h.map((e=>o.MF.fromModelSelection(e)))),1===h.length){const e=new c.y(h[0].positionLineNumber,h[0].positionColumn);t.revealPosition(e,0)}}_moveTo(e,t,i){return i?new d.L(e.selectionStartLineNumber,e.selectionStartColumn,t.lineNumber,t.column):new d.L(t.lineNumber,t.column,t.lineNumber,t.column)}}class C extends v{_move(e,t,i,s,n){return a.z.moveWordLeft(e,t,i,s,n)}}class b extends v{_move(e,t,i,s,n){return a.z.moveWordRight(e,t,i,s)}}class E extends s.DX{constructor(e){super(e),this._whitespaceHeuristics=e.whitespaceHeuristics,this._wordNavigationType=e.wordNavigationType}runEditorCommand(e,t,i){const s=e.get(g.JZ);if(!t.hasModel())return;const r=(0,l.i)(t.getOption(132),t.getOption(131)),o=t.getModel(),a=t.getSelections(),c=t.getOption(6),h=t.getOption(11),d=s.getLanguageConfiguration(o.getLanguageId()).getAutoClosingPairs(),u=t._getViewModel(),p=a.map((e=>{const i=this._delete({wordSeparators:r,model:o,selection:e,whitespaceHeuristics:this._whitespaceHeuristics,autoClosingDelete:t.getOption(9),autoClosingBrackets:c,autoClosingQuotes:h,autoClosingPairs:d,autoClosedCharacters:u.getCursorAutoClosedCharacters()},this._wordNavigationType);return new n.iu(i,"")}));t.pushUndoStop(),t.executeCommands(this.id,p),t.pushUndoStop()}}class S extends E{_delete(e,t){const i=a.z.deleteWordLeft(e,t);return i||new h.Q(1,1,1,1)}}class y extends E{_delete(e,t){const i=a.z.deleteWordRight(e,t);if(i)return i;const s=e.model.getLineCount(),n=e.model.getLineMaxColumn(s);return new h.Q(s,n,s,n)}}class w extends s.ks{constructor(){super({id:"deleteInsideWord",precondition:u.R.writable,label:p.kg("deleteInsideWord","Delete Word"),alias:"Delete Word"})}run(e,t,i){if(!t.hasModel())return;const s=(0,l.i)(t.getOption(132),t.getOption(131)),r=t.getModel(),o=t.getSelections().map((e=>{const t=a.z.deleteInsideWord(s,r,e);return new n.iu(t,"")}));t.pushUndoStop(),t.executeCommands(this.id,o),t.pushUndoStop()}}(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!1,wordNavigationType:0,id:"cursorWordStartLeft",precondition:void 0})}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!1,wordNavigationType:2,id:"cursorWordEndLeft",precondition:void 0})}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!1,wordNavigationType:1,id:"cursorWordLeft",precondition:void 0,kbOpts:{kbExpr:f.M$.and(u.R.textInputFocus,f.M$.and(m.f,_.nd)?.negate()),primary:2063,mac:{primary:527},weight:100}})}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!0,wordNavigationType:0,id:"cursorWordStartLeftSelect",precondition:void 0})}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!0,wordNavigationType:2,id:"cursorWordEndLeftSelect",precondition:void 0})}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!0,wordNavigationType:1,id:"cursorWordLeftSelect",precondition:void 0,kbOpts:{kbExpr:f.M$.and(u.R.textInputFocus,f.M$.and(m.f,_.nd)?.negate()),primary:3087,mac:{primary:1551},weight:100}})}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!1,wordNavigationType:0,id:"cursorWordStartRight",precondition:void 0})}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!1,wordNavigationType:2,id:"cursorWordEndRight",precondition:void 0,kbOpts:{kbExpr:f.M$.and(u.R.textInputFocus,f.M$.and(m.f,_.nd)?.negate()),primary:2065,mac:{primary:529},weight:100}})}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!1,wordNavigationType:2,id:"cursorWordRight",precondition:void 0})}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!0,wordNavigationType:0,id:"cursorWordStartRightSelect",precondition:void 0})}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!0,wordNavigationType:2,id:"cursorWordEndRightSelect",precondition:void 0,kbOpts:{kbExpr:f.M$.and(u.R.textInputFocus,f.M$.and(m.f,_.nd)?.negate()),primary:3089,mac:{primary:1553},weight:100}})}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!0,wordNavigationType:2,id:"cursorWordRightSelect",precondition:void 0})}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!1,wordNavigationType:3,id:"cursorWordAccessibilityLeft",precondition:void 0})}_move(e,t,i,s,n){return super._move((0,l.i)(r.qB.wordSeparators.defaultValue,e.intlSegmenterLocales),t,i,s,n)}}),(0,s.E_)(new class extends C{constructor(){super({inSelectionMode:!0,wordNavigationType:3,id:"cursorWordAccessibilityLeftSelect",precondition:void 0})}_move(e,t,i,s,n){return super._move((0,l.i)(r.qB.wordSeparators.defaultValue,e.intlSegmenterLocales),t,i,s,n)}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!1,wordNavigationType:3,id:"cursorWordAccessibilityRight",precondition:void 0})}_move(e,t,i,s,n){return super._move((0,l.i)(r.qB.wordSeparators.defaultValue,e.intlSegmenterLocales),t,i,s,n)}}),(0,s.E_)(new class extends b{constructor(){super({inSelectionMode:!0,wordNavigationType:3,id:"cursorWordAccessibilityRightSelect",precondition:void 0})}_move(e,t,i,s,n){return super._move((0,l.i)(r.qB.wordSeparators.defaultValue,e.intlSegmenterLocales),t,i,s,n)}}),(0,s.E_)(new class extends S{constructor(){super({whitespaceHeuristics:!1,wordNavigationType:0,id:"deleteWordStartLeft",precondition:u.R.writable})}}),(0,s.E_)(new class extends S{constructor(){super({whitespaceHeuristics:!1,wordNavigationType:2,id:"deleteWordEndLeft",precondition:u.R.writable})}}),(0,s.E_)(new class extends S{constructor(){super({whitespaceHeuristics:!0,wordNavigationType:0,id:"deleteWordLeft",precondition:u.R.writable,kbOpts:{kbExpr:u.R.textInputFocus,primary:2049,mac:{primary:513},weight:100}})}}),(0,s.E_)(new class extends y{constructor(){super({whitespaceHeuristics:!1,wordNavigationType:0,id:"deleteWordStartRight",precondition:u.R.writable})}}),(0,s.E_)(new class extends y{constructor(){super({whitespaceHeuristics:!1,wordNavigationType:2,id:"deleteWordEndRight",precondition:u.R.writable})}}),(0,s.E_)(new class extends y{constructor(){super({whitespaceHeuristics:!0,wordNavigationType:2,id:"deleteWordRight",precondition:u.R.writable,kbOpts:{kbExpr:u.R.textInputFocus,primary:2068,mac:{primary:532},weight:100}})}}),(0,s.Fl)(w)},46606:(e,t,i)=>{"use strict";var s=i(31450),n=i(97681),r=i(36677),o=i(60002),a=i(38728),l=i(50091);class c extends a.R7{constructor(){super({whitespaceHeuristics:!0,wordNavigationType:0,id:"deleteWordPartLeft",precondition:o.R.writable,kbOpts:{kbExpr:o.R.textInputFocus,primary:0,mac:{primary:769},weight:100}})}_delete(e,t){const i=n.c.deleteWordPartLeft(e);return i||new r.Q(1,1,1,1)}}class h extends a.R7{constructor(){super({whitespaceHeuristics:!0,wordNavigationType:2,id:"deleteWordPartRight",precondition:o.R.writable,kbOpts:{kbExpr:o.R.textInputFocus,primary:0,mac:{primary:788},weight:100}})}_delete(e,t){const i=n.c.deleteWordPartRight(e);if(i)return i;const s=e.model.getLineCount(),o=e.model.getLineMaxColumn(s);return new r.Q(s,o,s,o)}}class d extends a.Jk{_move(e,t,i,s,r){return n.c.moveWordPartLeft(e,t,i,r)}}l.w.registerCommandAlias("cursorWordPartStartLeft","cursorWordPartLeft");l.w.registerCommandAlias("cursorWordPartStartLeftSelect","cursorWordPartLeftSelect");class u extends a.Jk{_move(e,t,i,s,r){return n.c.moveWordPartRight(e,t,i)}}(0,s.E_)(new c),(0,s.E_)(new h),(0,s.E_)(new class extends d{constructor(){super({inSelectionMode:!1,wordNavigationType:0,id:"cursorWordPartLeft",precondition:void 0,kbOpts:{kbExpr:o.R.textInputFocus,primary:0,mac:{primary:783},weight:100}})}}),(0,s.E_)(new class extends d{constructor(){super({inSelectionMode:!0,wordNavigationType:0,id:"cursorWordPartLeftSelect",precondition:void 0,kbOpts:{kbExpr:o.R.textInputFocus,primary:0,mac:{primary:1807},weight:100}})}}),(0,s.E_)(new class extends u{constructor(){super({inSelectionMode:!1,wordNavigationType:2,id:"cursorWordPartRight",precondition:void 0,kbOpts:{kbExpr:o.R.textInputFocus,primary:0,mac:{primary:785},weight:100}})}}),(0,s.E_)(new class extends u{constructor(){super({inSelectionMode:!0,wordNavigationType:2,id:"cursorWordPartRightSelect",precondition:void 0,kbOpts:{kbExpr:o.R.textInputFocus,primary:0,mac:{primary:1809},weight:100}})}})},56800:(e,t,i)=>{"use strict";var s=i(8597),n=i(5662),r=i(31450),o=i(98067);class a extends n.jG{static{this.ID="editor.contrib.iPadShowKeyboard"}constructor(e){super(),this.editor=e,this.widget=null,o.un&&(this._register(e.onDidChangeConfiguration((()=>this.update()))),this.update())}update(){const e=!this.editor.getOption(92);!this.widget&&e?this.widget=new l(this.editor):this.widget&&!e&&(this.widget.dispose(),this.widget=null)}dispose(){super.dispose(),this.widget&&(this.widget.dispose(),this.widget=null)}}class l extends n.jG{static{this.ID="editor.contrib.ShowKeyboardWidget"}constructor(e){super(),this.editor=e,this._domNode=document.createElement("textarea"),this._domNode.className="iPadShowKeyboard",this._register(s.ko(this._domNode,"touchstart",(e=>{this.editor.focus()}))),this._register(s.ko(this._domNode,"focus",(e=>{this.editor.focus()}))),this.editor.addOverlayWidget(this)}dispose(){this.editor.removeOverlayWidget(this),super.dispose()}getId(){return l.ID}getDomNode(){return this._domNode}getPosition(){return{preference:1}}}(0,r.HW)(a.ID,a,3)},84325:(e,t,i)=>{"use strict";var s,n=i(8597),r=i(47661),o=i(5662),a=i(31450),l=i(62083),c=i(25982),h=i(20788),d=i(10154),u=i(24520),g=i(51861),p=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},m=function(e,t){return function(i,s){t(i,s,e)}};let f=class extends o.jG{static{s=this}static{this.ID="editor.contrib.inspectTokens"}static get(e){return e.getContribution(s.ID)}constructor(e,t,i){super(),this._editor=e,this._languageService=i,this._widget=null,this._register(this._editor.onDidChangeModel((e=>this.stop()))),this._register(this._editor.onDidChangeModelLanguage((e=>this.stop()))),this._register(l.dG.onDidChange((e=>this.stop()))),this._register(this._editor.onKeyUp((e=>9===e.keyCode&&this.stop())))}dispose(){this.stop(),super.dispose()}launch(){this._widget||this._editor.hasModel()&&(this._widget=new v(this._editor,this._languageService))}stop(){this._widget&&(this._widget.dispose(),this._widget=null)}};f=s=p([m(1,u.L),m(2,d.L)],f);class _ extends a.ks{constructor(){super({id:"editor.action.inspectTokens",label:g.YN.inspectTokensAction,alias:"Developer: Inspect Tokens",precondition:void 0})}run(e,t){const i=f.get(t);i?.launch()}}class v extends o.jG{static{this._ID="editor.contrib.inspectTokensWidget"}constructor(e,t){super(),this.allowEditorOverflow=!0,this._editor=e,this._languageService=t,this._model=this._editor.getModel(),this._domNode=document.createElement("div"),this._domNode.className="tokens-inspect-widget",this._tokenizationSupport=function(e,t){const i=l.dG.get(t);if(i)return i;const s=e.encodeLanguageId(t);return{getInitialState:()=>h.r3,tokenize:(e,i,s)=>(0,h.$H)(t,s),tokenizeEncoded:(e,t,i)=>(0,h.Lh)(s,i)}}(this._languageService.languageIdCodec,this._model.getLanguageId()),this._compute(this._editor.getPosition()),this._register(this._editor.onDidChangeCursorPosition((e=>this._compute(this._editor.getPosition())))),this._editor.addContentWidget(this)}dispose(){this._editor.removeContentWidget(this),super.dispose()}getId(){return v._ID}_compute(e){const t=this._getTokensAtLine(e.lineNumber);let i=0;for(let n=t.tokens1.length-1;n>=0;n--){const s=t.tokens1[n];if(e.column-1>=s.offset){i=n;break}}let s=0;for(let n=t.tokens2.length>>>1;n>=0;n--)if(e.column-1>=t.tokens2[n<<1]){s=n;break}const o=this._model.getLineContent(e.lineNumber);let a="";if(i{"use strict";var s=i(46359),n=i(71597),r=i(51861),o=i(80301),a=i(37882),l=i(73983),c=i(70125),h=i(64383),d=i(26690),u=i(6921),g=i(5662),p=i(74320);class m{constructor(){this.chunkCount=0,this.chunkOccurrences=new Map,this.documents=new Map}calculateScores(e,t){const i=this.computeEmbedding(e),s=new Map,n=[];for(const[r,o]of this.documents){if(t.isCancellationRequested)return[];for(const e of o.chunks){const t=this.computeSimilarityScore(e,i,s);t>0&&n.push({key:r,score:t})}}return n}static termFrequencies(e){return function(e){const t=new Map;for(const i of e)t.set(i,(t.get(i)??0)+1);return t}(m.splitTerms(e))}static*splitTerms(e){const t=e=>e.toLowerCase();for(const[i]of e.matchAll(/\b\p{Letter}[\p{Letter}\d]{2,}\b/gu)){yield t(i);const e=i.replace(/([a-z])([A-Z])/g,"$1 $2").split(/\s+/g);if(e.length>1)for(const i of e)i.length>2&&/\p{Letter}{3,}/gu.test(i)&&(yield t(i))}}updateDocuments(e){for(const{key:t}of e)this.deleteDocument(t);for(const t of e){const e=[];for(const i of t.textChunks){const t=m.termFrequencies(i);for(const e of t.keys())this.chunkOccurrences.set(e,(this.chunkOccurrences.get(e)??0)+1);e.push({text:i,tf:t})}this.chunkCount+=e.length,this.documents.set(t.key,{chunks:e})}return this}deleteDocument(e){const t=this.documents.get(e);if(t){this.documents.delete(e),this.chunkCount-=t.chunks.length;for(const e of t.chunks)for(const t of e.tf.keys()){const e=this.chunkOccurrences.get(t);if("number"===typeof e){const i=e-1;i<=0?this.chunkOccurrences.delete(t):this.chunkOccurrences.set(t,i)}}}}computeSimilarityScore(e,t,i){let s=0;for(const[n,r]of Object.entries(t)){const t=e.tf.get(n);if(!t)continue;let o=i.get(n);"number"!==typeof o&&(o=this.computeIdf(n),i.set(n,o));s+=t*o*r}return s}computeEmbedding(e){const t=m.termFrequencies(e);return this.computeTfidf(t)}computeIdf(e){const t=this.chunkOccurrences.get(e)??0;return t>0?Math.log((this.chunkCount+1)/t):0}computeTfidf(e){const t=Object.create(null);for(const[i,s]of e){const e=this.computeIdf(i);e>0&&(t[i]=s*e)}return t}}var f,_=i(78209),v=i(50091),C=i(84001),b=i(59599),E=i(63591),S=i(98031),y=i(18801),w=i(90766),L=i(18447),R=i(631);function T(e){const t=e;return Array.isArray(t.items)}function x(e){const t=e;return!!t.picks&&t.additionalPicks instanceof Promise}!function(e){e[e.NO_ACTION=0]="NO_ACTION",e[e.CLOSE_PICKER=1]="CLOSE_PICKER",e[e.REFRESH_PICKER=2]="REFRESH_PICKER",e[e.REMOVE_ITEM=3]="REMOVE_ITEM"}(f||(f={}));class k extends g.jG{constructor(e,t){super(),this.prefix=e,this.options=t}provide(e,t,i){const s=new g.Cm;let n;e.canAcceptInBackground=!!this.options?.canAcceptInBackground,e.matchOnLabel=e.matchOnDescription=e.matchOnDetail=e.sortByLabel=!1;const r=s.add(new g.HE),o=async()=>{const s=r.value=new g.Cm;n?.dispose(!0),e.busy=!1,n=new L.Qi(t);const o=n.token;let a=e.value.substring(this.prefix.length);this.options?.shouldSkipTrimPickFilter||(a=a.trim());const l=this._getPicks(a,s,o,i),c=(t,i)=>{let s,n;if(T(t)?(s=t.items,n=t.active):s=t,0===s.length){if(i)return!1;(a.length>0||e.hideInput)&&this.options?.noResultsPick&&(s=(0,R.Tn)(this.options.noResultsPick)?[this.options.noResultsPick(a)]:[this.options.noResultsPick])}return e.items=s,n&&(e.activeItems=[n]),!0},h=async t=>{let i=!1,s=!1;await Promise.all([(async()=>{"number"===typeof t.mergeDelay&&(await(0,w.wR)(t.mergeDelay),o.isCancellationRequested)||s||(i=c(t.picks,!0))})(),(async()=>{e.busy=!0;try{const s=await t.additionalPicks;if(o.isCancellationRequested)return;let n,r,a,l;if(T(t.picks)?(n=t.picks.items,r=t.picks.active):n=t.picks,T(s)?(a=s.items,l=s.active):a=s,a.length>0||!i){let t;if(!r&&!l){const i=e.activeItems[0];i&&-1!==n.indexOf(i)&&(t=i)}c({items:[...n,...a],active:r||l||t})}}finally{o.isCancellationRequested||(e.busy=!1),s=!0}})()])};if(null===l);else if(x(l))await h(l);else if(l instanceof Promise){e.busy=!0;try{const e=await l;if(o.isCancellationRequested)return;x(e)?await h(e):c(e)}finally{o.isCancellationRequested||(e.busy=!1)}}else c(l)};s.add(e.onDidChangeValue((()=>o()))),o(),s.add(e.onDidAccept((t=>{if(i?.handleAccept)return t.inBackground||e.hide(),void i.handleAccept?.(e.activeItems[0]);const[s]=e.selectedItems;"function"===typeof s?.accept&&(t.inBackground||e.hide(),s.accept(e.keyMods,t))})));const a=async(i,s)=>{if("function"!==typeof s.trigger)return;const n=s.buttons?.indexOf(i)??-1;if(n>=0){const i=s.trigger(n,e.keyMods),r="number"===typeof i?i:await i;if(t.isCancellationRequested)return;switch(r){case f.NO_ACTION:break;case f.CLOSE_PICKER:e.hide();break;case f.REFRESH_PICKER:o();break;case f.REMOVE_ITEM:{const t=e.items.indexOf(s);if(-1!==t){const i=e.items.slice(),s=i.splice(t,1),n=e.activeItems.filter((e=>e!==s[0])),r=e.keepScrollPosition;e.keepScrollPosition=!0,e.items=i,n&&(e.activeItems=n),e.keepScrollPosition=r}break}}}};return s.add(e.onDidTriggerItemButton((({button:e,item:t})=>a(e,t)))),s.add(e.onDidTriggerSeparatorButton((({button:e,separator:t})=>a(e,t)))),s}}var A,N,I=i(9711),O=i(90651),D=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},M=function(e,t){return function(i,s){t(i,s,e)}};let P=class extends k{static{A=this}static{this.PREFIX=">"}static{this.TFIDF_THRESHOLD=.5}static{this.TFIDF_MAX_RESULTS=5}static{this.WORD_FILTER=(0,d.or)(d.WP,d.J1,d.Tt)}constructor(e,t,i,s,n,r){super(A.PREFIX,e),this.instantiationService=t,this.keybindingService=i,this.commandService=s,this.telemetryService=n,this.dialogService=r,this.commandsHistory=this._register(this.instantiationService.createInstance(F)),this.options=e}async _getPicks(e,t,i,s){const n=await this.getCommandPicks(i);if(i.isCancellationRequested)return[];const r=(0,u.P)((()=>{const t=new m;t.updateDocuments(n.map((e=>({key:e.commandId,textChunks:[this.getTfIdfChunk(e)]}))));return function(e){const t=e.slice(0);t.sort(((e,t)=>t.score-e.score));const i=t[0]?.score??0;if(i>0)for(const s of t)s.score/=i;return t}(t.calculateScores(e,i)).filter((e=>e.score>A.TFIDF_THRESHOLD)).slice(0,A.TFIDF_MAX_RESULTS)})),o=[];for(const u of n){const t=A.WORD_FILTER(e,u.label)??void 0,s=u.commandAlias?A.WORD_FILTER(e,u.commandAlias)??void 0:void 0;if(t||s)u.highlights={label:t,detail:this.options.showAlias?s:void 0},o.push(u);else if(e===u.commandId)o.push(u);else if(e.length>=3){const e=r();if(i.isCancellationRequested)return[];const t=e.find((e=>e.key===u.commandId));t&&(u.tfIdfScore=t.score,o.push(u))}}const a=new Map;for(const u of o){const e=a.get(u.label);e?(u.description=u.commandId,e.description=e.commandId):a.set(u.label,u)}o.sort(((e,t)=>{if(e.tfIdfScore&&t.tfIdfScore)return e.tfIdfScore===t.tfIdfScore?e.label.localeCompare(t.label):t.tfIdfScore-e.tfIdfScore;if(e.tfIdfScore)return 1;if(t.tfIdfScore)return-1;const i=this.commandsHistory.peek(e.commandId),s=this.commandsHistory.peek(t.commandId);if(i&&s)return i>s?-1:1;if(i)return-1;if(s)return 1;if(this.options.suggestedCommandIds){const i=this.options.suggestedCommandIds.has(e.commandId),s=this.options.suggestedCommandIds.has(t.commandId);if(i&&s)return 0;if(i)return-1;if(s)return 1}return e.label.localeCompare(t.label)}));const l=[];let c=!1,h=!0,d=!!this.options.suggestedCommandIds;for(let u=0;u{const t=await this.getAdditionalCommandPicks(n,o,e,i);if(i.isCancellationRequested)return[];const r=t.map((e=>this.toCommandPick(e,s)));return h&&"separator"!==r[0]?.type&&r.unshift({type:"separator",label:(0,_.kg)("suggested","similar commands")}),r})()}:l}toCommandPick(e,t){if("separator"===e.type)return e;const i=this.keybindingService.lookupKeybinding(e.commandId),s=i?(0,_.kg)("commandPickAriaLabelWithKeybinding","{0}, {1}",e.label,i.getAriaLabel()):e.label;return{...e,ariaLabel:s,detail:this.options.showAlias&&e.commandAlias!==e.label?e.commandAlias:void 0,keybinding:i,accept:async()=>{this.commandsHistory.push(e.commandId),this.telemetryService.publicLog2("workbenchActionExecuted",{id:e.commandId,from:t?.from??"quick open"});try{e.args?.length?await this.commandService.executeCommand(e.commandId,...e.args):await this.commandService.executeCommand(e.commandId)}catch(i){(0,h.MB)(i)||this.dialogService.error((0,_.kg)("canNotRun","Command '{0}' resulted in an error",e.label),(0,c.r)(i))}}}}getTfIdfChunk({label:e,commandAlias:t,commandDescription:i}){let s=e;return t&&t!==e&&(s+=` - ${t}`),i&&i.value!==e&&(s+=` - ${i.value===i.original?i.value:`${i.value} (${i.original})`}`),s}};P=A=D([M(1,E._Y),M(2,S.b),M(3,v.d),M(4,O.k),M(5,b.X)],P);let F=class extends g.jG{static{N=this}static{this.DEFAULT_COMMANDS_HISTORY_LENGTH=50}static{this.PREF_KEY_CACHE="commandPalette.mru.cache"}static{this.PREF_KEY_COUNTER="commandPalette.mru.counter"}static{this.counter=1}static{this.hasChanges=!1}constructor(e,t,i){super(),this.storageService=e,this.configurationService=t,this.logService=i,this.configuredCommandsHistoryLength=0,this.updateConfiguration(),this.load(),this.registerListeners()}registerListeners(){this._register(this.configurationService.onDidChangeConfiguration((e=>this.updateConfiguration(e)))),this._register(this.storageService.onWillSaveState((e=>{e.reason===I.LP.SHUTDOWN&&this.saveState()})))}updateConfiguration(e){e&&!e.affectsConfiguration("workbench.commandPalette.history")||(this.configuredCommandsHistoryLength=N.getConfiguredCommandHistoryLength(this.configurationService),N.cache&&N.cache.limit!==this.configuredCommandsHistoryLength&&(N.cache.limit=this.configuredCommandsHistoryLength,N.hasChanges=!0))}load(){const e=this.storageService.get(N.PREF_KEY_CACHE,0);let t;if(e)try{t=JSON.parse(e)}catch(s){this.logService.error(`[CommandsHistory] invalid data: ${s}`)}const i=N.cache=new p.qK(this.configuredCommandsHistoryLength,1);if(t){let e;e=t.usesLRU?t.entries:t.entries.sort(((e,t)=>e.value-t.value)),e.forEach((e=>i.set(e.key,e.value)))}N.counter=this.storageService.getNumber(N.PREF_KEY_COUNTER,0,N.counter)}push(e){N.cache&&(N.cache.set(e,N.counter++),N.hasChanges=!0)}peek(e){return N.cache?.peek(e)}saveState(){if(!N.cache)return;if(!N.hasChanges)return;const e={usesLRU:!0,entries:[]};N.cache.forEach(((t,i)=>e.entries.push({key:i,value:t}))),this.storageService.store(N.PREF_KEY_CACHE,JSON.stringify(e),0,0),this.storageService.store(N.PREF_KEY_COUNTER,N.counter,0,0),N.hasChanges=!1}static getConfiguredCommandHistoryLength(e){const t=e.getValue(),i=t.workbench?.commandPalette?.history;return"number"===typeof i?i:N.DEFAULT_COMMANDS_HISTORY_LENGTH}};F=N=D([M(0,I.CS),M(1,C.pG),M(2,y.rr)],F);class U extends P{constructor(e,t,i,s,n,r){super(e,t,i,s,n,r)}getCodeEditorCommandPicks(){const e=this.activeTextEditorControl;if(!e)return[];const t=[];for(const i of e.getSupportedActions()){let e;i.metadata?.description&&(e=(0,l.f)(i.metadata.description)?i.metadata.description:{original:i.metadata.description,value:i.metadata.description}),t.push({commandId:i.id,commandAlias:i.alias,commandDescription:e,label:(0,a.pS)(i.label)||i.id})}return t}}var H=i(31450),B=i(60002),W=i(51467),V=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};let G=class extends U{get activeTextEditorControl(){return this.codeEditorService.getFocusedCodeEditor()??void 0}constructor(e,t,i,s,n,r){super({showAlias:!1},e,i,s,n,r),this.codeEditorService=t}async getCommandPicks(){return this.getCodeEditorCommandPicks()}hasAdditionalCommandPicks(){return!1}async getAdditionalCommandPicks(){return[]}};G=V([z(0,E._Y),z(1,o.T),z(2,S.b),z(3,v.d),z(4,O.k),z(5,b.X)],G);class j extends H.ks{static{this.ID="editor.action.quickCommand"}constructor(){super({id:j.ID,label:r.gf.quickCommandActionLabel,alias:"Command Palette",precondition:void 0,kbOpts:{kbExpr:B.R.focus,primary:59,weight:100},contextMenuOpts:{group:"z_commands",order:1}})}run(e){e.get(W.GK).quickAccess.show(G.PREFIX)}}(0,H.Fl)(j),s.O.as(n.Fd.Quickaccess).registerQuickAccessProvider({ctor:G,prefix:G.PREFIX,helpEntries:[{description:r.gf.quickCommandHelp,commandId:j.ID}]})},81091:(e,t,i)=>{"use strict";var s=i(5662),n=i(34326),r=i(12437),o=i(78209);class a extends r.o{static{this.PREFIX=":"}constructor(){super({canAcceptInBackground:!0})}provideWithoutTextEditor(e){const t=(0,o.kg)("cannotRunGotoLine","Open a text editor first to go to a line.");return e.items=[{label:t}],e.ariaLabel=t,s.jG.None}provideWithTextEditor(e,t,i){const r=e.editor,o=new s.Cm;o.add(t.onDidAccept((i=>{const[s]=t.selectedItems;if(s){if(!this.isValidLineNumber(r,s.lineNumber))return;this.gotoLocation(e,{range:this.toRange(s.lineNumber,s.column),keyMods:t.keyMods,preserveFocus:i.inBackground}),i.inBackground||t.hide()}})));const l=()=>{const e=this.parsePosition(r,t.value.trim().substr(a.PREFIX.length)),i=this.getPickLabel(r,e.lineNumber,e.column);if(t.items=[{lineNumber:e.lineNumber,column:e.column,label:i}],t.ariaLabel=i,!this.isValidLineNumber(r,e.lineNumber))return void this.clearDecorations(r);const s=this.toRange(e.lineNumber,e.column);r.revealRangeInCenter(s,0),this.addDecorations(r,s)};l(),o.add(t.onDidChangeValue((()=>l())));const c=(0,n.jA)(r);if(c){2===c.getOptions().get(68).renderType&&(c.updateOptions({lineNumbers:"on"}),o.add((0,s.s)((()=>c.updateOptions({lineNumbers:"relative"})))))}return o}toRange(e=1,t=1){return{startLineNumber:e,startColumn:t,endLineNumber:e,endColumn:t}}parsePosition(e,t){const i=t.split(/,|:|#/).map((e=>parseInt(e,10))).filter((e=>!isNaN(e))),s=this.lineCount(e)+1;return{lineNumber:i[0]>0?i[0]:s+i[0],column:i[1]}}getPickLabel(e,t,i){if(this.isValidLineNumber(e,t))return this.isValidColumn(e,t,i)?(0,o.kg)("gotoLineColumnLabel","Go to line {0} and character {1}.",t,i):(0,o.kg)("gotoLineLabel","Go to line {0}.",t);const s=e.getPosition()||{lineNumber:1,column:1},n=this.lineCount(e);return n>1?(0,o.kg)("gotoLineLabelEmptyWithLimit","Current Line: {0}, Character: {1}. Type a line number between 1 and {2} to navigate to.",s.lineNumber,s.column,n):(0,o.kg)("gotoLineLabelEmpty","Current Line: {0}, Character: {1}. Type a line number to navigate to.",s.lineNumber,s.column)}isValidLineNumber(e,t){return!(!t||"number"!==typeof t)&&(t>0&&t<=this.lineCount(e))}isValidColumn(e,t,i){if(!i||"number"!==typeof i)return!1;const s=this.getModel(e);if(!s)return!1;const n={lineNumber:t,column:i};return s.validatePosition(n).equals(n)}lineCount(e){return this.getModel(e)?.getLineCount()??0}}var l=i(46359),c=i(71597),h=i(80301),d=i(51861),u=i(41234),g=i(31450),p=i(60002),m=i(51467),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class extends a{constructor(e){super(),this.editorService=e,this.onDidActiveTextEditorControlChange=u.Jh.None}get activeTextEditorControl(){return this.editorService.getFocusedCodeEditor()??void 0}};v=f([_(0,h.T)],v);class C extends g.ks{static{this.ID="editor.action.gotoLine"}constructor(){super({id:C.ID,label:d.Hw.gotoLineActionLabel,alias:"Go to Line/Column...",precondition:void 0,kbOpts:{kbExpr:p.R.focus,primary:2085,mac:{primary:293},weight:100}})}run(e){e.get(m.GK).quickAccess.show(v.PREFIX)}}(0,g.Fl)(C),l.O.as(c.Fd.Quickaccess).registerQuickAccessProvider({ctor:v,prefix:v.PREFIX,helpEntries:[{description:d.Hw.gotoLineActionLabel,commandId:C.ID}]})},28211:(e,t,i)=>{"use strict";i(97791),i(93409);var s=i(90766),n=i(18447),r=i(10350),o=i(25689),a=i(26690),l=i(74027),c=i(98067),h=i(91508);const d=[void 0,[]];function u(e,t,i=0,s=0){const n=t;return n.values&&n.values.length>1?function(e,t,i,s){let n=0;const r=[];for(const o of t){const[t,a]=g(e,o,i,s);if("number"!==typeof t)return d;n+=t,r.push(...a)}return[n,p(r)]}(e,n.values,i,s):g(e,t,i,s)}function g(e,t,i,s){const n=(0,a.dt)(t.original,t.originalLowercase,i,e,e.toLowerCase(),s,{firstMatchCanBeWeak:!0,boostFullMatch:!0});return n?[n[0],(0,a.WJ)(n)]:d}Object.freeze({score:0});function p(e){const t=e.sort(((e,t)=>e.start-t.start)),i=[];let s;for(const n of t)s&&m(s,n)?(s.start=Math.min(s.start,n.start),s.end=Math.max(s.end,n.end)):(s=n,i.push(n));return i}function m(e,t){return!(e.end=0,o=f(e);let a;const c=e.split(" ");if(c.length>1)for(const l of c){const e=f(l),{pathNormalized:t,normalized:i,normalizedLowercase:s}=v(l);i&&(a||(a=[]),a.push({original:l,originalLowercase:l.toLowerCase(),pathNormalized:t,normalized:i,normalizedLowercase:s,expectContiguousMatch:e}))}return{original:e,originalLowercase:t,pathNormalized:i,normalized:s,normalizedLowercase:n,values:a,containsPathSeparator:r,expectContiguousMatch:o}}function v(e){let t;t=c.uF?e.replace(/\//g,l.Vn):e.replace(/\\/g,l.Vn);const i=(0,h.wB)(t).replace(/\s|"/g,"");return{pathNormalized:t,normalized:i,normalizedLowercase:i.toLowerCase()}}function C(e){return Array.isArray(e)?_(e.map((e=>e.original)).join(" ")):_(e.original)}var b,E=i(5662),S=i(36677),y=i(62083),w=i(29999),L=i(12437),R=i(78209),T=i(56942),x=i(46041),k=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},A=function(e,t){return function(i,s){t(i,s,e)}};let N=class extends L.o{static{b=this}static{this.PREFIX="@"}static{this.SCOPE_PREFIX=":"}static{this.PREFIX_BY_CATEGORY=`${this.PREFIX}${this.SCOPE_PREFIX}`}constructor(e,t,i=Object.create(null)){super(i),this._languageFeaturesService=e,this._outlineModelService=t,this.options=i,this.options.canAcceptInBackground=!0}provideWithoutTextEditor(e){return this.provideLabelPick(e,(0,R.kg)("cannotRunGotoSymbolWithoutEditor","To go to a symbol, first open a text editor with symbol information.")),E.jG.None}provideWithTextEditor(e,t,i,s){const n=e.editor,r=this.getModel(n);return r?this._languageFeaturesService.documentSymbolProvider.has(r)?this.doProvideWithEditorSymbols(e,r,t,i,s):this.doProvideWithoutEditorSymbols(e,r,t,i):E.jG.None}doProvideWithoutEditorSymbols(e,t,i,s){const n=new E.Cm;return this.provideLabelPick(i,(0,R.kg)("cannotRunGotoSymbolWithoutSymbolProvider","The active text editor does not provide symbol information.")),(async()=>{await this.waitForLanguageSymbolRegistry(t,n)&&!s.isCancellationRequested&&n.add(this.doProvideWithEditorSymbols(e,t,i,s))})(),n}provideLabelPick(e,t){e.items=[{label:t,index:0,kind:14}],e.ariaLabel=t}async waitForLanguageSymbolRegistry(e,t){if(this._languageFeaturesService.documentSymbolProvider.has(e))return!0;const i=new s.Zv,n=t.add(this._languageFeaturesService.documentSymbolProvider.onDidChange((()=>{this._languageFeaturesService.documentSymbolProvider.has(e)&&(n.dispose(),i.complete(!0))})));return t.add((0,E.s)((()=>i.complete(!1)))),i.p}doProvideWithEditorSymbols(e,t,i,s,r){const o=e.editor,a=new E.Cm;a.add(i.onDidAccept((t=>{const[s]=i.selectedItems;s&&s.range&&(this.gotoLocation(e,{range:s.range.selection,keyMods:i.keyMods,preserveFocus:t.inBackground}),r?.handleAccept?.(s),t.inBackground||i.hide())}))),a.add(i.onDidTriggerItemButton((({item:t})=>{t&&t.range&&(this.gotoLocation(e,{range:t.range.selection,keyMods:i.keyMods,forceSideBySide:!0}),i.hide())})));const l=this.getDocumentSymbols(t,s);let c;const h=async e=>{c?.dispose(!0),i.busy=!1,c=new n.Qi(s),i.busy=!0;try{const n=_(i.value.substr(b.PREFIX.length).trim()),r=await this.doGetSymbolPicks(l,n,void 0,c.token,t);if(s.isCancellationRequested)return;if(r.length>0){if(i.items=r,e&&0===n.original.length){const t=(0,x.Uk)(r,(t=>Boolean("separator"!==t.type&&t.range&&S.Q.containsPosition(t.range.decoration,e))));t&&(i.activeItems=[t])}}else n.original.length>0?this.provideLabelPick(i,(0,R.kg)("noMatchingSymbolResults","No matching editor symbols")):this.provideLabelPick(i,(0,R.kg)("noSymbolResults","No editor symbols"))}finally{s.isCancellationRequested||(i.busy=!1)}};return a.add(i.onDidChangeValue((()=>h(void 0)))),h(o.getSelection()?.getPosition()),a.add(i.onDidChangeActive((()=>{const[e]=i.activeItems;e&&e.range&&(o.revealRangeInCenter(e.range.selection,0),this.addDecorations(o,e.range.decoration))}))),a}async doGetSymbolPicks(e,t,i,s,n){const a=await e;if(s.isCancellationRequested)return[];const l=0===t.original.indexOf(b.SCOPE_PREFIX),c=l?1:0;let d,g,p;t.values&&t.values.length>1?(d=C(t.values[0]),g=C(t.values.slice(1))):d=t;const m=this.options?.openSideBySideDirection?.();m&&(p=[{iconClass:"right"===m?o.L.asClassName(r.W.splitHorizontal):o.L.asClassName(r.W.splitVertical),tooltip:"right"===m?(0,R.kg)("openToSide","Open to the Side"):(0,R.kg)("openToBottom","Open to the Bottom")}]);const f=[];for(let E=0;Ec){let F=!1;if(d!==t&&([k,A]=u(T,{...t,values:void 0},c,x),"number"===typeof k&&(F=!0)),"number"!==typeof k&&([k,A]=u(T,d,c,x),"number"!==typeof k))continue;if(!F&&g){if(M&&g.original.length>0&&([N,D]=u(M,g)),"number"!==typeof N)continue;"number"===typeof k&&(k+=N)}}const P=w.tags&&w.tags.indexOf(1)>=0;f.push({index:E,kind:w.kind,score:k,label:T,ariaLabel:(0,y.PK)(w.name,w.kind),description:M,highlights:P?void 0:{label:A,description:D},range:{selection:S.Q.collapseToStart(w.selectionRange),decoration:w.range},uri:n.uri,symbolName:L,strikethrough:P,buttons:p})}const _=f.sort(((e,t)=>l?this.compareByKindAndScore(e,t):this.compareByScore(e,t)));let v=[];if(l){let U,H,B=0;function W(){H&&"number"===typeof U&&B>0&&(H.label=(0,h.GP)(O[U]||I,B))}for(const V of _)U!==V.kind?(W(),U=V.kind,B=1,H={type:"separator"},v.push(H)):B++,v.push(V);W()}else _.length>0&&(v=[{label:(0,R.kg)("symbols","symbols ({0})",f.length),type:"separator"},..._]);return v}compareByScore(e,t){if("number"!==typeof e.score&&"number"===typeof t.score)return 1;if("number"===typeof e.score&&"number"!==typeof t.score)return-1;if("number"===typeof e.score&&"number"===typeof t.score){if(e.score>t.score)return-1;if(e.scoret.index?1:0}compareByKindAndScore(e,t){const i=O[e.kind]||I,s=O[t.kind]||I,n=i.localeCompare(s);return 0===n?this.compareByScore(e,t):n}async getDocumentSymbols(e,t){const i=await this._outlineModelService.getOrCreate(e,t);return t.isCancellationRequested?[]:i.asListOfDocumentSymbols()}};N=b=k([A(0,T.ILanguageFeaturesService),A(1,w.gW)],N);const I=(0,R.kg)("property","properties ({0})"),O={5:(0,R.kg)("method","methods ({0})"),11:(0,R.kg)("function","functions ({0})"),8:(0,R.kg)("_constructor","constructors ({0})"),12:(0,R.kg)("variable","variables ({0})"),4:(0,R.kg)("class","classes ({0})"),22:(0,R.kg)("struct","structs ({0})"),23:(0,R.kg)("event","events ({0})"),24:(0,R.kg)("operator","operators ({0})"),10:(0,R.kg)("interface","interfaces ({0})"),2:(0,R.kg)("namespace","namespaces ({0})"),3:(0,R.kg)("package","packages ({0})"),25:(0,R.kg)("typeParameter","type parameters ({0})"),1:(0,R.kg)("modules","modules ({0})"),6:(0,R.kg)("property","properties ({0})"),9:(0,R.kg)("enum","enumerations ({0})"),21:(0,R.kg)("enumMember","enumeration members ({0})"),14:(0,R.kg)("string","strings ({0})"),0:(0,R.kg)("file","files ({0})"),17:(0,R.kg)("array","arrays ({0})"),15:(0,R.kg)("number","numbers ({0})"),16:(0,R.kg)("boolean","booleans ({0})"),18:(0,R.kg)("object","objects ({0})"),19:(0,R.kg)("key","keys ({0})"),7:(0,R.kg)("field","fields ({0})"),13:(0,R.kg)("constant","constants ({0})")};var D=i(46359),M=i(71597),P=i(80301),F=i(51861),U=i(41234),H=i(31450),B=i(60002),W=i(51467),V=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},z=function(e,t){return function(i,s){t(i,s,e)}};let G=class extends N{constructor(e,t,i){super(t,i),this.editorService=e,this.onDidActiveTextEditorControlChange=U.Jh.None}get activeTextEditorControl(){return this.editorService.getFocusedCodeEditor()??void 0}};G=V([z(0,P.T),z(1,T.ILanguageFeaturesService),z(2,w.gW)],G);class j extends H.ks{static{this.ID="editor.action.quickOutline"}constructor(){super({id:j.ID,label:F.n9.quickOutlineActionLabel,alias:"Go to Symbol...",precondition:B.R.hasDocumentSymbolProvider,kbOpts:{kbExpr:B.R.focus,primary:3117,weight:100},contextMenuOpts:{group:"navigation",order:3}})}run(e){e.get(W.GK).quickAccess.show(N.PREFIX,{itemActivation:W.C1.NONE})}}(0,H.Fl)(j),D.O.as(M.Fd.Quickaccess).registerQuickAccessProvider({ctor:G,prefix:N.PREFIX,helpEntries:[{description:F.n9.quickOutlineActionLabel,prefix:N.PREFIX,commandId:j.ID},{description:F.n9.quickOutlineByCategoryActionLabel,prefix:N.PREFIX_BY_CATEGORY}]})},6429:(e,t,i)=>{"use strict";var s,n=i(46359),r=i(71597),o=i(51861),a=i(78209),l=i(5662),c=i(98031),h=i(51467),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},u=function(e,t){return function(i,s){t(i,s,e)}};let g=class{static{s=this}static{this.PREFIX="?"}constructor(e,t){this.quickInputService=e,this.keybindingService=t,this.registry=n.O.as(r.Fd.Quickaccess)}provide(e){const t=new l.Cm;return t.add(e.onDidAccept((()=>{const[t]=e.selectedItems;t&&this.quickInputService.quickAccess.show(t.prefix,{preserveValue:!0})}))),t.add(e.onDidChangeValue((e=>{const t=this.registry.getQuickAccessProvider(e.substr(s.PREFIX.length));t&&t.prefix&&t.prefix!==s.PREFIX&&this.quickInputService.quickAccess.show(t.prefix,{preserveValue:!0})}))),e.items=this.getQuickAccessProviders().filter((e=>e.prefix!==s.PREFIX)),t}getQuickAccessProviders(){return this.registry.getQuickAccessProviders().sort(((e,t)=>e.prefix.localeCompare(t.prefix))).flatMap((e=>this.createPicks(e)))}createPicks(e){return e.helpEntries.map((t=>{const i=t.prefix||e.prefix,s=i||"\u2026";return{prefix:i,label:s,keybinding:t.commandId?this.keybindingService.lookupKeybinding(t.commandId):void 0,ariaLabel:(0,a.kg)("helpPickAriaLabel","{0}, {1}",s,t.description),description:t.description}}))}};g=s=d([u(0,h.GK),u(1,c.b)],g),n.O.as(r.Fd.Quickaccess).registerQuickAccessProvider({ctor:g,prefix:"",helpEntries:[{description:o.oq.helpQuickAccessActionLabel}]})},57377:(e,t,i)=>{"use strict";var s=i(31450),n=i(80301),r=i(23646),o=i(84001),a=i(32848),l=i(63591),c=i(58591),h=i(9711),d=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},u=function(e,t){return function(i,s){t(i,s,e)}};let g=class extends r.X{constructor(e,t,i,s,n,r,o){super(!0,e,t,i,s,n,r,o)}};g=d([u(1,a.fN),u(2,n.T),u(3,c.Ot),u(4,l._Y),u(5,h.CS),u(6,o.pG)],g),(0,s.HW)(r.X.ID,g,4)},10424:(e,t,i)=>{"use strict";i.d(t,{aQ:()=>I,nr:()=>O,Sx:()=>B,po:()=>N,tj:()=>A});var s=i(8597),n=i(60413),r=i(47661),o=i(41234),a=i(62083),l=i(25982);class c{constructor(e,t,i,s,n){this._parsedThemeRuleBrand=void 0,this.token=e,this.index=t,this.fontStyle=i,this.foreground=s,this.background=n}}const h=/^#?([0-9A-Fa-f]{6})([0-9A-Fa-f]{2})?$/;class d{constructor(){this._lastColorId=0,this._id2color=[],this._color2id=new Map}getId(e){if(null===e)return 0;const t=e.match(h);if(!t)throw new Error("Illegal value for token color: "+e);e=t[1].toUpperCase();let i=this._color2id.get(e);return i||(i=++this._lastColorId,this._color2id.set(e,i),this._id2color[i]=r.Q1.fromHex("#"+e),i)}getColorMap(){return this._id2color.slice(0)}}class u{static createFromRawTokenTheme(e,t){return this.createFromParsedTokenTheme(function(e){if(!e||!Array.isArray(e))return[];const t=[];let i=0;for(let s=0,n=e.length;s{const i=function(e,t){return et?1:0}(e.token,t.token);return 0!==i?i:e.index-t.index}));let i=0,s="000000",n="ffffff";for(;e.length>=1&&""===e[0].token;){const t=e.shift();-1!==t.fontStyle&&(i=t.fontStyle),null!==t.foreground&&(s=t.foreground),null!==t.background&&(n=t.background)}const r=new d;for(const h of t)r.getId(h);const o=r.getId(s),a=r.getId(n),l=new p(i,o,a),c=new m(l);for(let h=0,d=e.length;h>>0,this._cache.set(t,i)}return(i|e)>>>0}}const g=/\b(comment|string|regex|regexp)\b/;class p{constructor(e,t,i){this._themeTrieElementRuleBrand=void 0,this._fontStyle=e,this._foreground=t,this._background=i,this.metadata=(this._fontStyle<<11|this._foreground<<15|this._background<<24)>>>0}clone(){return new p(this._fontStyle,this._foreground,this._background)}acceptOverwrite(e,t,i){-1!==e&&(this._fontStyle=e),0!==t&&(this._foreground=t),0!==i&&(this._background=i),this.metadata=(this._fontStyle<<11|this._foreground<<15|this._background<<24)>>>0}}class m{constructor(e){this._themeTrieElementBrand=void 0,this._mainRule=e,this._children=new Map}match(e){if(""===e)return this._mainRule;const t=e.indexOf(".");let i,s;-1===t?(i=e,s=""):(i=e.substring(0,t),s=e.substring(t+1));const n=this._children.get(i);return"undefined"!==typeof n?n.match(s):this._mainRule}insert(e,t,i,s){if(""===e)return void this._mainRule.acceptOverwrite(t,i,s);const n=e.indexOf(".");let r,o;-1===n?(r=e,o=""):(r=e.substring(0,n),o=e.substring(n+1));let a=this._children.get(r);"undefined"===typeof a&&(a=new m(this._mainRule.clone()),this._children.set(r,a)),a.insert(o,t,i,s)}}var f=i(87119),_=i(66261);const v={base:"vs",inherit:!1,rules:[{token:"",foreground:"000000",background:"fffffe"},{token:"invalid",foreground:"cd3131"},{token:"emphasis",fontStyle:"italic"},{token:"strong",fontStyle:"bold"},{token:"variable",foreground:"001188"},{token:"variable.predefined",foreground:"4864AA"},{token:"constant",foreground:"dd0000"},{token:"comment",foreground:"008000"},{token:"number",foreground:"098658"},{token:"number.hex",foreground:"3030c0"},{token:"regexp",foreground:"800000"},{token:"annotation",foreground:"808080"},{token:"type",foreground:"008080"},{token:"delimiter",foreground:"000000"},{token:"delimiter.html",foreground:"383838"},{token:"delimiter.xml",foreground:"0000FF"},{token:"tag",foreground:"800000"},{token:"tag.id.pug",foreground:"4F76AC"},{token:"tag.class.pug",foreground:"4F76AC"},{token:"meta.scss",foreground:"800000"},{token:"metatag",foreground:"e00000"},{token:"metatag.content.html",foreground:"FF0000"},{token:"metatag.html",foreground:"808080"},{token:"metatag.xml",foreground:"808080"},{token:"metatag.php",fontStyle:"bold"},{token:"key",foreground:"863B00"},{token:"string.key.json",foreground:"A31515"},{token:"string.value.json",foreground:"0451A5"},{token:"attribute.name",foreground:"FF0000"},{token:"attribute.value",foreground:"0451A5"},{token:"attribute.value.number",foreground:"098658"},{token:"attribute.value.unit",foreground:"098658"},{token:"attribute.value.html",foreground:"0000FF"},{token:"attribute.value.xml",foreground:"0000FF"},{token:"string",foreground:"A31515"},{token:"string.html",foreground:"0000FF"},{token:"string.sql",foreground:"FF0000"},{token:"string.yaml",foreground:"0451A5"},{token:"keyword",foreground:"0000FF"},{token:"keyword.json",foreground:"0451A5"},{token:"keyword.flow",foreground:"AF00DB"},{token:"keyword.flow.scss",foreground:"0000FF"},{token:"operator.scss",foreground:"666666"},{token:"operator.sql",foreground:"778899"},{token:"operator.swift",foreground:"666666"},{token:"predefined.sql",foreground:"C700C7"}],colors:{[_.YtV]:"#FFFFFE",[_.By2]:"#000000",[_.tan]:"#E5EBF1",[f.vV]:"#D3D3D3",[f.H0]:"#939393",[_.QwA]:"#ADD6FF4D"}},C={base:"vs-dark",inherit:!1,rules:[{token:"",foreground:"D4D4D4",background:"1E1E1E"},{token:"invalid",foreground:"f44747"},{token:"emphasis",fontStyle:"italic"},{token:"strong",fontStyle:"bold"},{token:"variable",foreground:"74B0DF"},{token:"variable.predefined",foreground:"4864AA"},{token:"variable.parameter",foreground:"9CDCFE"},{token:"constant",foreground:"569CD6"},{token:"comment",foreground:"608B4E"},{token:"number",foreground:"B5CEA8"},{token:"number.hex",foreground:"5BB498"},{token:"regexp",foreground:"B46695"},{token:"annotation",foreground:"cc6666"},{token:"type",foreground:"3DC9B0"},{token:"delimiter",foreground:"DCDCDC"},{token:"delimiter.html",foreground:"808080"},{token:"delimiter.xml",foreground:"808080"},{token:"tag",foreground:"569CD6"},{token:"tag.id.pug",foreground:"4F76AC"},{token:"tag.class.pug",foreground:"4F76AC"},{token:"meta.scss",foreground:"A79873"},{token:"meta.tag",foreground:"CE9178"},{token:"metatag",foreground:"DD6A6F"},{token:"metatag.content.html",foreground:"9CDCFE"},{token:"metatag.html",foreground:"569CD6"},{token:"metatag.xml",foreground:"569CD6"},{token:"metatag.php",fontStyle:"bold"},{token:"key",foreground:"9CDCFE"},{token:"string.key.json",foreground:"9CDCFE"},{token:"string.value.json",foreground:"CE9178"},{token:"attribute.name",foreground:"9CDCFE"},{token:"attribute.value",foreground:"CE9178"},{token:"attribute.value.number.css",foreground:"B5CEA8"},{token:"attribute.value.unit.css",foreground:"B5CEA8"},{token:"attribute.value.hex.css",foreground:"D4D4D4"},{token:"string",foreground:"CE9178"},{token:"string.sql",foreground:"FF0000"},{token:"keyword",foreground:"569CD6"},{token:"keyword.flow",foreground:"C586C0"},{token:"keyword.json",foreground:"CE9178"},{token:"keyword.flow.scss",foreground:"569CD6"},{token:"operator.scss",foreground:"909090"},{token:"operator.sql",foreground:"778899"},{token:"operator.swift",foreground:"909090"},{token:"predefined.sql",foreground:"FF00FF"}],colors:{[_.YtV]:"#1E1E1E",[_.By2]:"#D4D4D4",[_.tan]:"#3A3D41",[f.vV]:"#404040",[f.H0]:"#707070",[_.QwA]:"#ADD6FF26"}},b={base:"hc-black",inherit:!1,rules:[{token:"",foreground:"FFFFFF",background:"000000"},{token:"invalid",foreground:"f44747"},{token:"emphasis",fontStyle:"italic"},{token:"strong",fontStyle:"bold"},{token:"variable",foreground:"1AEBFF"},{token:"variable.parameter",foreground:"9CDCFE"},{token:"constant",foreground:"569CD6"},{token:"comment",foreground:"608B4E"},{token:"number",foreground:"FFFFFF"},{token:"regexp",foreground:"C0C0C0"},{token:"annotation",foreground:"569CD6"},{token:"type",foreground:"3DC9B0"},{token:"delimiter",foreground:"FFFF00"},{token:"delimiter.html",foreground:"FFFF00"},{token:"tag",foreground:"569CD6"},{token:"tag.id.pug",foreground:"4F76AC"},{token:"tag.class.pug",foreground:"4F76AC"},{token:"meta",foreground:"D4D4D4"},{token:"meta.tag",foreground:"CE9178"},{token:"metatag",foreground:"569CD6"},{token:"metatag.content.html",foreground:"1AEBFF"},{token:"metatag.html",foreground:"569CD6"},{token:"metatag.xml",foreground:"569CD6"},{token:"metatag.php",fontStyle:"bold"},{token:"key",foreground:"9CDCFE"},{token:"string.key",foreground:"9CDCFE"},{token:"string.value",foreground:"CE9178"},{token:"attribute.name",foreground:"569CD6"},{token:"attribute.value",foreground:"3FF23F"},{token:"string",foreground:"CE9178"},{token:"string.sql",foreground:"FF0000"},{token:"keyword",foreground:"569CD6"},{token:"keyword.flow",foreground:"C586C0"},{token:"operator.sql",foreground:"778899"},{token:"operator.swift",foreground:"909090"},{token:"predefined.sql",foreground:"FF00FF"}],colors:{[_.YtV]:"#000000",[_.By2]:"#FFFFFF",[f.vV]:"#FFFFFF",[f.H0]:"#FFFFFF"}},E={base:"hc-light",inherit:!1,rules:[{token:"",foreground:"292929",background:"FFFFFF"},{token:"invalid",foreground:"B5200D"},{token:"emphasis",fontStyle:"italic"},{token:"strong",fontStyle:"bold"},{token:"variable",foreground:"264F70"},{token:"variable.predefined",foreground:"4864AA"},{token:"constant",foreground:"dd0000"},{token:"comment",foreground:"008000"},{token:"number",foreground:"098658"},{token:"number.hex",foreground:"3030c0"},{token:"regexp",foreground:"800000"},{token:"annotation",foreground:"808080"},{token:"type",foreground:"008080"},{token:"delimiter",foreground:"000000"},{token:"delimiter.html",foreground:"383838"},{token:"tag",foreground:"800000"},{token:"tag.id.pug",foreground:"4F76AC"},{token:"tag.class.pug",foreground:"4F76AC"},{token:"meta.scss",foreground:"800000"},{token:"metatag",foreground:"e00000"},{token:"metatag.content.html",foreground:"B5200D"},{token:"metatag.html",foreground:"808080"},{token:"metatag.xml",foreground:"808080"},{token:"metatag.php",fontStyle:"bold"},{token:"key",foreground:"863B00"},{token:"string.key.json",foreground:"A31515"},{token:"string.value.json",foreground:"0451A5"},{token:"attribute.name",foreground:"264F78"},{token:"attribute.value",foreground:"0451A5"},{token:"string",foreground:"A31515"},{token:"string.sql",foreground:"B5200D"},{token:"keyword",foreground:"0000FF"},{token:"keyword.flow",foreground:"AF00DB"},{token:"operator.sql",foreground:"778899"},{token:"operator.swift",foreground:"666666"},{token:"predefined.sql",foreground:"C700C7"}],colors:{[_.YtV]:"#FFFFFF",[_.By2]:"#292929",[f.vV]:"#292929",[f.H0]:"#292929"}};var S=i(46359),y=i(47612),w=i(5662),L=i(86723),R=i(25689),T=i(61394);class x{getIcon(e){const t=(0,T.HT)();let i=e.defaults;for(;R.L.isThemeIcon(i);){const e=t.getIcon(i.id);if(!e)return;i=e.defaults}return i}}var k=i(25893);const A="vs",N="vs-dark",I="hc-black",O="hc-light",D=S.O.as(_.FdG.ColorContribution),M=S.O.as(y.Fd.ThemingContribution);class P{constructor(e,t){this.semanticHighlighting=!1,this.themeData=t;const i=t.base;e.length>0?(F(e)?this.id=e:this.id=i+" "+e,this.themeName=e):(this.id=i,this.themeName=i),this.colors=null,this.defaultColors=Object.create(null),this._tokenTheme=null}get base(){return this.themeData.base}notifyBaseUpdated(){this.themeData.inherit&&(this.colors=null,this._tokenTheme=null)}getColors(){if(!this.colors){const e=new Map;for(const t in this.themeData.colors)e.set(t,r.Q1.fromHex(this.themeData.colors[t]));if(this.themeData.inherit){const t=U(this.themeData.base);for(const i in t.colors)e.has(i)||e.set(i,r.Q1.fromHex(t.colors[i]))}this.colors=e}return this.colors}getColor(e,t){const i=this.getColors().get(e);return i||(!1!==t?this.getDefault(e):void 0)}getDefault(e){let t=this.defaultColors[e];return t||(t=D.resolveDefaultColor(e,this),this.defaultColors[e]=t,t)}defines(e){return this.getColors().has(e)}get type(){switch(this.base){case A:return L.zM.LIGHT;case I:return L.zM.HIGH_CONTRAST_DARK;case O:return L.zM.HIGH_CONTRAST_LIGHT;default:return L.zM.DARK}}get tokenTheme(){if(!this._tokenTheme){let e=[],t=[];if(this.themeData.inherit){const i=U(this.themeData.base);e=i.rules,i.encodedTokensColors&&(t=i.encodedTokensColors)}const i=this.themeData.colors["editor.foreground"],s=this.themeData.colors["editor.background"];if(i||s){const t={token:""};i&&(t.foreground=i),s&&(t.background=s),e.push(t)}e=e.concat(this.themeData.rules),this.themeData.encodedTokensColors&&(t=this.themeData.encodedTokensColors),this._tokenTheme=u.createFromRawTokenTheme(e,t)}return this._tokenTheme}getTokenStyleMetadata(e,t,i){const s=this.tokenTheme._match([e].concat(t).join(".")).metadata,n=l.x.getForeground(s),r=l.x.getFontStyle(s);return{foreground:n,italic:Boolean(1&r),bold:Boolean(2&r),underline:Boolean(4&r),strikethrough:Boolean(8&r)}}}function F(e){return e===A||e===N||e===I||e===O}function U(e){switch(e){case A:return v;case N:return C;case I:return b;case O:return E}}function H(e){const t=U(e);return new P(e,t)}class B extends w.jG{constructor(){super(),this._onColorThemeChange=this._register(new o.vl),this.onDidColorThemeChange=this._onColorThemeChange.event,this._onProductIconThemeChange=this._register(new o.vl),this.onDidProductIconThemeChange=this._onProductIconThemeChange.event,this._environment=Object.create(null),this._builtInProductIconTheme=new x,this._autoDetectHighContrast=!0,this._knownThemes=new Map,this._knownThemes.set(A,H(A)),this._knownThemes.set(N,H(N)),this._knownThemes.set(I,H(I)),this._knownThemes.set(O,H(O));const e=this._register(function(e){const t=new w.Cm,i=t.add(new o.vl),n=(0,T.HT)();return t.add(n.onDidChange((()=>i.fire()))),e&&t.add(e.onDidProductIconThemeChange((()=>i.fire()))),{dispose:()=>t.dispose(),onDidChange:i.event,getCSS(){const t=e?e.getProductIconTheme():new x,i={},r=[],o=[];for(const e of n.getIcons()){const n=t.getIcon(e);if(!n)continue;const a=n.font,l=`--vscode-icon-${e.id}-font-family`,c=`--vscode-icon-${e.id}-content`;a?(i[a.id]=a.definition,o.push(`${l}: ${(0,s.yt)(a.id)};`,`${c}: '${n.fontCharacter}';`),r.push(`.codicon-${e.id}:before { content: '${n.fontCharacter}'; font-family: ${(0,s.yt)(a.id)}; }`)):(o.push(`${c}: '${n.fontCharacter}'; ${l}: 'codicon';`),r.push(`.codicon-${e.id}:before { content: '${n.fontCharacter}'; }`))}for(const e in i){const t=i[e],n=t.weight?`font-weight: ${t.weight};`:"",o=t.style?`font-style: ${t.style};`:"",a=t.src.map((e=>`${(0,s.Tf)(e.location)} format('${e.format}')`)).join(", ");r.push(`@font-face { src: ${a}; font-family: ${(0,s.yt)(e)};${n}${o} font-display: block; }`)}return r.push(`:root { ${o.join(" ")} }`),r.join("\n")}}}(this));this._codiconCSS=e.getCSS(),this._themeCSS="",this._allCSS=`${this._codiconCSS}\n${this._themeCSS}`,this._globalStyleElement=null,this._styleElements=[],this._colorMapOverride=null,this.setTheme(A),this._onOSSchemeChanged(),this._register(e.onDidChange((()=>{this._codiconCSS=e.getCSS(),this._updateCSS()}))),(0,n.Dy)(k.G,"(forced-colors: active)",(()=>{this._onOSSchemeChanged()}))}registerEditorContainer(e){return s.Cl(e)?this._registerShadowDomContainer(e):this._registerRegularEditorContainer()}_registerRegularEditorContainer(){return this._globalStyleElement||(this._globalStyleElement=s.li(void 0,(e=>{e.className="monaco-colors",e.textContent=this._allCSS})),this._styleElements.push(this._globalStyleElement)),w.jG.None}_registerShadowDomContainer(e){const t=s.li(e,(e=>{e.className="monaco-colors",e.textContent=this._allCSS}));return this._styleElements.push(t),{dispose:()=>{for(let e=0;e{t.base===e&&t.notifyBaseUpdated()})),this._theme.themeName===e&&this.setTheme(e)}getColorTheme(){return this._theme}setColorMapOverride(e){this._colorMapOverride=e,this._updateThemeOrColorMap()}setTheme(e){let t;t=this._knownThemes.has(e)?this._knownThemes.get(e):this._knownThemes.get(A),this._updateActualTheme(t)}_updateActualTheme(e){e&&this._theme!==e&&(this._theme=e,this._updateThemeOrColorMap())}_onOSSchemeChanged(){if(this._autoDetectHighContrast){const e=k.G.matchMedia("(forced-colors: active)").matches;if(e!==(0,L.Bb)(this._theme.type)){let t;t=(0,L.HD)(this._theme.type)?e?I:N:e?O:A,this._updateActualTheme(this._knownThemes.get(t))}}}setAutoDetectHighContrast(e){this._autoDetectHighContrast=e,this._onOSSchemeChanged()}_updateThemeOrColorMap(){const e=[],t={},i={addRule:i=>{t[i]||(e.push(i),t[i]=!0)}};M.getThemingParticipants().forEach((e=>e(this._theme,i,this._environment)));const s=[];for(const r of D.getColors()){const e=this._theme.getColor(r.id,!0);e&&s.push(`${(0,_.Bbc)(r.id)}: ${e.toString()};`)}i.addRule(`.monaco-editor, .monaco-diff-editor, .monaco-component { ${s.join("\n")} }`);const n=this._colorMapOverride||this._theme.tokenTheme.getColorMap();i.addRule(function(e){const t=[];for(let i=1,s=e.length;ie.textContent=this._allCSS))}getFileIconTheme(){return{hasFileIcons:!1,hasFolderIcons:!1,hidesExplorerArrows:!1}}getProductIconTheme(){return this._builtInProductIconTheme}}},22890:(e,t,i)=>{"use strict";var s=i(31450),n=i(24520),r=i(51861),o=i(86723),a=i(10424);class l extends s.ks{constructor(){super({id:"editor.action.toggleHighContrast",label:r.E6.toggleHighContrast,alias:"Toggle High Contrast Theme",precondition:void 0}),this._originalThemeName=null}run(e,t){const i=e.get(n.L),s=i.getColorTheme();(0,o.Bb)(s.type)?(i.setTheme(this._originalThemeName||((0,o.HD)(s.type)?a.po:a.tj)),this._originalThemeName=null):(i.setTheme((0,o.HD)(s.type)?a.aQ:a.nr),this._originalThemeName=s.themeName)}}(0,s.Fl)(l)},24520:(e,t,i)=>{"use strict";i.d(t,{L:()=>s});const s=(0,i(63591).u1)("themeService")},11272:(e,t,i)=>{"use strict";var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,l=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of l(t))c.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u=class{constructor(e,t,i){this._onDidChange=new d.Emitter,this._languageId=e,this.setOptions(t),this.setModeConfiguration(i)}get onDidChange(){return this._onDidChange.event}get languageId(){return this._languageId}get modeConfiguration(){return this._modeConfiguration}get diagnosticsOptions(){return this.options}get options(){return this._options}setOptions(e){this._options=e||Object.create(null),this._onDidChange.fire(this)}setDiagnosticsOptions(e){this.setOptions(e)}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(this)}},g={validate:!0,lint:{compatibleVendorPrefixes:"ignore",vendorPrefix:"warning",duplicateProperties:"warning",emptyRules:"warning",importStatement:"ignore",boxModel:"ignore",universalSelector:"ignore",zeroUnits:"ignore",fontFaceProperties:"warning",hexColorLength:"error",argumentsInColorFunction:"error",unknownProperties:"warning",ieHack:"ignore",unknownVendorSpecificProperties:"ignore",propertyIgnoredDueToDisplay:"warning",important:"ignore",float:"ignore",idSelector:"ignore"},data:{useDefaultDataProvider:!0},format:{newlineBetweenSelectors:!0,newlineBetweenRules:!0,spaceAroundSelectorSeparator:!1,braceStyle:"collapse",maxPreserveNewLines:void 0,preserveNewLines:!0}},p={completionItems:!0,hovers:!0,documentSymbols:!0,definitions:!0,references:!0,documentHighlights:!0,rename:!0,colors:!0,foldingRanges:!0,diagnostics:!0,selectionRanges:!0,documentFormattingEdits:!0,documentRangeFormattingEdits:!0},m=new u("css",g,p),f=new u("scss",g,p),_=new u("less",g,p);function v(){return i.e(225).then(i.bind(i,70225))}d.languages.css={cssDefaults:m,lessDefaults:_,scssDefaults:f},d.languages.onLanguage("less",(()=>{v().then((e=>e.setupMode(_)))})),d.languages.onLanguage("scss",(()=>{v().then((e=>e.setupMode(f)))})),d.languages.onLanguage("css",(()=>{v().then((e=>e.setupMode(m)))}))},89518:(e,t,i)=>{"use strict";var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,l=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of l(t))c.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u=class{constructor(e,t,i){this._onDidChange=new d.Emitter,this._languageId=e,this.setOptions(t),this.setModeConfiguration(i)}get onDidChange(){return this._onDidChange.event}get languageId(){return this._languageId}get options(){return this._options}get modeConfiguration(){return this._modeConfiguration}setOptions(e){this._options=e||Object.create(null),this._onDidChange.fire(this)}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(this)}},g={format:{tabSize:4,insertSpaces:!1,wrapLineLength:120,unformatted:'default": "a, abbr, acronym, b, bdo, big, br, button, cite, code, dfn, em, i, img, input, kbd, label, map, object, q, samp, select, small, span, strong, sub, sup, textarea, tt, var',contentUnformatted:"pre",indentInnerHtml:!1,preserveNewLines:!0,maxPreserveNewLines:void 0,indentHandlebars:!1,endWithNewline:!1,extraLiners:"head, body, /html",wrapAttributes:"auto"},suggest:{},data:{useDefaultDataProvider:!0}};function p(e){return{completionItems:!0,hovers:!0,documentSymbols:!0,links:!0,documentHighlights:!0,rename:!0,colors:!0,foldingRanges:!0,selectionRanges:!0,diagnostics:e===m,documentFormattingEdits:e===m,documentRangeFormattingEdits:e===m}}var m="html",f="handlebars",_="razor",v=w(m,g,p(m)),C=v.defaults,b=w(f,g,p(f)),E=b.defaults,S=w(_,g,p(_)),y=S.defaults;function w(e,t=g,s=p(e)){const n=new u(e,t,s);let r;const o=d.languages.onLanguage(e,(async()=>{r=(await i.e(8821).then(i.bind(i,68821))).setupMode(n)}));return{defaults:n,dispose(){o.dispose(),r?.dispose(),r=void 0}}}d.languages.html={htmlDefaults:C,razorDefaults:y,handlebarDefaults:E,htmlLanguageService:v,handlebarLanguageService:b,razorLanguageService:S,registerHTMLLanguageService:w}},99669:(e,t,i)=>{"use strict";var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,l=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of l(t))c.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u=new class{constructor(e,t,i){this._onDidChange=new d.Emitter,this._languageId=e,this.setDiagnosticsOptions(t),this.setModeConfiguration(i)}get onDidChange(){return this._onDidChange.event}get languageId(){return this._languageId}get modeConfiguration(){return this._modeConfiguration}get diagnosticsOptions(){return this._diagnosticsOptions}setDiagnosticsOptions(e){this._diagnosticsOptions=e||Object.create(null),this._onDidChange.fire(this)}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(this)}}("json",{validate:!0,allowComments:!0,schemas:[],enableSchemaRequest:!1,schemaRequest:"warning",schemaValidation:"warning",comments:"error",trailingCommas:"error"},{documentFormattingEdits:!0,documentRangeFormattingEdits:!0,completionItems:!0,hovers:!0,documentSymbols:!0,tokens:!0,colors:!0,foldingRanges:!0,diagnostics:!0,selectionRanges:!0});function g(){return i.e(6447).then(i.bind(i,66447))}d.languages.json={jsonDefaults:u,getWorker:()=>g().then((e=>e.getWorker()))},d.languages.register({id:"json",extensions:[".json",".bowerrc",".jshintrc",".jscsrc",".eslintrc",".babelrc",".har"],aliases:["JSON","json"],mimetypes:["application/json"]}),d.languages.onLanguage("json",(()=>{g().then((e=>e.setupMode(u)))}))},24152:(e,t,i)=>{"use strict";i.d(t,{IF:()=>C});var s,n,r=i(80781),o=Object.defineProperty,a=Object.getOwnPropertyDescriptor,l=Object.getOwnPropertyNames,c=Object.prototype.hasOwnProperty,h=(e,t,i,s)=>{if(t&&"object"===typeof t||"function"===typeof t)for(let n of l(t))c.call(e,n)||n===i||o(e,n,{get:()=>t[n],enumerable:!(s=a(t,n))||s.enumerable});return e},d={};h(d,s=r,"default"),n&&h(n,s,"default");var u=(e=>(e[e.None=0]="None",e[e.CommonJS=1]="CommonJS",e[e.AMD=2]="AMD",e[e.UMD=3]="UMD",e[e.System=4]="System",e[e.ES2015=5]="ES2015",e[e.ESNext=99]="ESNext",e))(u||{}),g=(e=>(e[e.None=0]="None",e[e.Preserve=1]="Preserve",e[e.React=2]="React",e[e.ReactNative=3]="ReactNative",e[e.ReactJSX=4]="ReactJSX",e[e.ReactJSXDev=5]="ReactJSXDev",e))(g||{}),p=(e=>(e[e.CarriageReturnLineFeed=0]="CarriageReturnLineFeed",e[e.LineFeed=1]="LineFeed",e))(p||{}),m=(e=>(e[e.ES3=0]="ES3",e[e.ES5=1]="ES5",e[e.ES2015=2]="ES2015",e[e.ES2016=3]="ES2016",e[e.ES2017=4]="ES2017",e[e.ES2018=5]="ES2018",e[e.ES2019=6]="ES2019",e[e.ES2020=7]="ES2020",e[e.ESNext=99]="ESNext",e[e.JSON=100]="JSON",e[e.Latest=99]="Latest",e))(m||{}),f=(e=>(e[e.Classic=1]="Classic",e[e.NodeJs=2]="NodeJs",e))(f||{}),_=class{constructor(e,t,i,s,n){this._onDidChange=new d.Emitter,this._onDidExtraLibsChange=new d.Emitter,this._extraLibs=Object.create(null),this._removedExtraLibs=Object.create(null),this._eagerModelSync=!1,this.setCompilerOptions(e),this.setDiagnosticsOptions(t),this.setWorkerOptions(i),this.setInlayHintsOptions(s),this.setModeConfiguration(n),this._onDidExtraLibsChangeTimeout=-1}get onDidChange(){return this._onDidChange.event}get onDidExtraLibsChange(){return this._onDidExtraLibsChange.event}get modeConfiguration(){return this._modeConfiguration}get workerOptions(){return this._workerOptions}get inlayHintsOptions(){return this._inlayHintsOptions}getExtraLibs(){return this._extraLibs}addExtraLib(e,t){let i;if(i="undefined"===typeof t?`ts:extralib-${Math.random().toString(36).substring(2,15)}`:t,this._extraLibs[i]&&this._extraLibs[i].content===e)return{dispose:()=>{}};let s=1;return this._removedExtraLibs[i]&&(s=this._removedExtraLibs[i]+1),this._extraLibs[i]&&(s=this._extraLibs[i].version+1),this._extraLibs[i]={content:e,version:s},this._fireOnDidExtraLibsChangeSoon(),{dispose:()=>{let e=this._extraLibs[i];e&&e.version===s&&(delete this._extraLibs[i],this._removedExtraLibs[i]=s,this._fireOnDidExtraLibsChangeSoon())}}}setExtraLibs(e){for(const t in this._extraLibs)this._removedExtraLibs[t]=this._extraLibs[t].version;if(this._extraLibs=Object.create(null),e&&e.length>0)for(const t of e){const e=t.filePath||`ts:extralib-${Math.random().toString(36).substring(2,15)}`,i=t.content;let s=1;this._removedExtraLibs[e]&&(s=this._removedExtraLibs[e]+1),this._extraLibs[e]={content:i,version:s}}this._fireOnDidExtraLibsChangeSoon()}_fireOnDidExtraLibsChangeSoon(){-1===this._onDidExtraLibsChangeTimeout&&(this._onDidExtraLibsChangeTimeout=window.setTimeout((()=>{this._onDidExtraLibsChangeTimeout=-1,this._onDidExtraLibsChange.fire(void 0)}),0))}getCompilerOptions(){return this._compilerOptions}setCompilerOptions(e){this._compilerOptions=e||Object.create(null),this._onDidChange.fire(void 0)}getDiagnosticsOptions(){return this._diagnosticsOptions}setDiagnosticsOptions(e){this._diagnosticsOptions=e||Object.create(null),this._onDidChange.fire(void 0)}setWorkerOptions(e){this._workerOptions=e||Object.create(null),this._onDidChange.fire(void 0)}setInlayHintsOptions(e){this._inlayHintsOptions=e||Object.create(null),this._onDidChange.fire(void 0)}setMaximumWorkerIdleTime(e){}setEagerModelSync(e){this._eagerModelSync=e}getEagerModelSync(){return this._eagerModelSync}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(void 0)}},v={completionItems:!0,hovers:!0,documentSymbols:!0,definitions:!0,references:!0,documentHighlights:!0,rename:!0,diagnostics:!0,documentRangeFormattingEdits:!0,signatureHelp:!0,onTypeFormattingEdits:!0,codeActions:!0,inlayHints:!0},C=new _({allowNonTsExtensions:!0,target:99},{noSemanticValidation:!1,noSyntaxValidation:!1,onlyVisible:!1},{},{},v),b=new _({allowNonTsExtensions:!0,allowJs:!0,target:99},{noSemanticValidation:!0,noSyntaxValidation:!1,onlyVisible:!1},{},{},v);function E(){return i.e(8979).then(i.bind(i,78979))}d.languages.typescript={ModuleKind:u,JsxEmit:g,NewLineKind:p,ScriptTarget:m,ModuleResolutionKind:f,typescriptVersion:"5.4.5",typescriptDefaults:C,javascriptDefaults:b,getTypeScriptWorker:()=>E().then((e=>e.getTypeScriptWorker())),getJavaScriptWorker:()=>E().then((e=>e.getJavaScriptWorker()))},d.languages.onLanguage("typescript",(()=>E().then((e=>e.setupTypeScript(C))))),d.languages.onLanguage("javascript",(()=>E().then((e=>e.setupJavaScript(b)))))},78209:(e,t,i)=>{"use strict";function s(){return globalThis._VSCODE_NLS_MESSAGES}function n(){return globalThis._VSCODE_NLS_LANGUAGE}i.d(t,{i8:()=>n,Ec:()=>s,kg:()=>a,aS:()=>c});const r="pseudo"===n()||"undefined"!==typeof document&&document.location&&document.location.hash.indexOf("pseudo=true")>=0;function o(e,t){let i;return i=0===t.length?e:e.replace(/\{(\d+)\}/g,((e,i)=>{const s=i[0],n=t[s];let r=e;return"string"===typeof n?r=n:"number"!==typeof n&&"boolean"!==typeof n&&void 0!==n&&null!==n||(r=String(n)),r})),r&&(i="\uff3b"+i.replace(/[aouei]/g,"$&$&")+"\uff3d"),i}function a(e,t,...i){return o("number"===typeof e?l(e,t):t,i)}function l(e,t){const i=s()?.[e];if("string"!==typeof i){if("string"===typeof t)return t;throw new Error(`!!! NLS MISSING: ${e} !!!`)}return i}function c(e,t,...i){let s;s="number"===typeof e?l(e,t):t;const n=o(s,i);return{value:n,original:t===s?n:o(t,i)}}},96282:(e,t,i)=>{"use strict";i.d(t,{Z:()=>s});const s=new class{constructor(){this._implementations=[]}register(e){return this._implementations.push(e),{dispose:()=>{const t=this._implementations.indexOf(e);-1!==t&&this._implementations.splice(t,1)}}}getImplementations(){return this._implementations}}},253:(e,t,i)=>{"use strict";i.d(t,{f:()=>r,j:()=>n});var s=i(32848);const n=(0,i(63591).u1)("accessibilityService"),r=new s.N1("accessibilityModeEnabled",!1)},87213:(e,t,i)=>{"use strict";i.d(t,{Nt:()=>n,Rh:()=>a});var s=i(78209);const n=(0,i(63591).u1)("accessibilitySignalService");Symbol("AcknowledgeDocCommentsToken");class r{static register(e){return new r(e.fileName)}static{this.error=r.register({fileName:"error.mp3"})}static{this.warning=r.register({fileName:"warning.mp3"})}static{this.success=r.register({fileName:"success.mp3"})}static{this.foldedArea=r.register({fileName:"foldedAreas.mp3"})}static{this.break=r.register({fileName:"break.mp3"})}static{this.quickFixes=r.register({fileName:"quickFixes.mp3"})}static{this.taskCompleted=r.register({fileName:"taskCompleted.mp3"})}static{this.taskFailed=r.register({fileName:"taskFailed.mp3"})}static{this.terminalBell=r.register({fileName:"terminalBell.mp3"})}static{this.diffLineInserted=r.register({fileName:"diffLineInserted.mp3"})}static{this.diffLineDeleted=r.register({fileName:"diffLineDeleted.mp3"})}static{this.diffLineModified=r.register({fileName:"diffLineModified.mp3"})}static{this.chatRequestSent=r.register({fileName:"chatRequestSent.mp3"})}static{this.chatResponseReceived1=r.register({fileName:"chatResponseReceived1.mp3"})}static{this.chatResponseReceived2=r.register({fileName:"chatResponseReceived2.mp3"})}static{this.chatResponseReceived3=r.register({fileName:"chatResponseReceived3.mp3"})}static{this.chatResponseReceived4=r.register({fileName:"chatResponseReceived4.mp3"})}static{this.clear=r.register({fileName:"clear.mp3"})}static{this.save=r.register({fileName:"save.mp3"})}static{this.format=r.register({fileName:"format.mp3"})}static{this.voiceRecordingStarted=r.register({fileName:"voiceRecordingStarted.mp3"})}static{this.voiceRecordingStopped=r.register({fileName:"voiceRecordingStopped.mp3"})}static{this.progress=r.register({fileName:"progress.mp3"})}constructor(e){this.fileName=e}}class o{constructor(e){this.randomOneOf=e}}class a{constructor(e,t,i,s,n,r){this.sound=e,this.name=t,this.legacySoundSettingsKey=i,this.settingsKey=s,this.legacyAnnouncementSettingsKey=n,this.announcementMessage=r}static{this._signals=new Set}static register(e){const t=new o("randomOneOf"in e.sound?e.sound.randomOneOf:[e.sound]),i=new a(t,e.name,e.legacySoundSettingsKey,e.settingsKey,e.legacyAnnouncementSettingsKey,e.announcementMessage);return a._signals.add(i),i}static{this.errorAtPosition=a.register({name:(0,s.kg)("accessibilitySignals.positionHasError.name","Error at Position"),sound:r.error,announcementMessage:(0,s.kg)("accessibility.signals.positionHasError","Error"),settingsKey:"accessibility.signals.positionHasError",delaySettingsKey:"accessibility.signalOptions.delays.errorAtPosition"})}static{this.warningAtPosition=a.register({name:(0,s.kg)("accessibilitySignals.positionHasWarning.name","Warning at Position"),sound:r.warning,announcementMessage:(0,s.kg)("accessibility.signals.positionHasWarning","Warning"),settingsKey:"accessibility.signals.positionHasWarning",delaySettingsKey:"accessibility.signalOptions.delays.warningAtPosition"})}static{this.errorOnLine=a.register({name:(0,s.kg)("accessibilitySignals.lineHasError.name","Error on Line"),sound:r.error,legacySoundSettingsKey:"audioCues.lineHasError",legacyAnnouncementSettingsKey:"accessibility.alert.error",announcementMessage:(0,s.kg)("accessibility.signals.lineHasError","Error on Line"),settingsKey:"accessibility.signals.lineHasError"})}static{this.warningOnLine=a.register({name:(0,s.kg)("accessibilitySignals.lineHasWarning.name","Warning on Line"),sound:r.warning,legacySoundSettingsKey:"audioCues.lineHasWarning",legacyAnnouncementSettingsKey:"accessibility.alert.warning",announcementMessage:(0,s.kg)("accessibility.signals.lineHasWarning","Warning on Line"),settingsKey:"accessibility.signals.lineHasWarning"})}static{this.foldedArea=a.register({name:(0,s.kg)("accessibilitySignals.lineHasFoldedArea.name","Folded Area on Line"),sound:r.foldedArea,legacySoundSettingsKey:"audioCues.lineHasFoldedArea",legacyAnnouncementSettingsKey:"accessibility.alert.foldedArea",announcementMessage:(0,s.kg)("accessibility.signals.lineHasFoldedArea","Folded"),settingsKey:"accessibility.signals.lineHasFoldedArea"})}static{this.break=a.register({name:(0,s.kg)("accessibilitySignals.lineHasBreakpoint.name","Breakpoint on Line"),sound:r.break,legacySoundSettingsKey:"audioCues.lineHasBreakpoint",legacyAnnouncementSettingsKey:"accessibility.alert.breakpoint",announcementMessage:(0,s.kg)("accessibility.signals.lineHasBreakpoint","Breakpoint"),settingsKey:"accessibility.signals.lineHasBreakpoint"})}static{this.inlineSuggestion=a.register({name:(0,s.kg)("accessibilitySignals.lineHasInlineSuggestion.name","Inline Suggestion on Line"),sound:r.quickFixes,legacySoundSettingsKey:"audioCues.lineHasInlineSuggestion",settingsKey:"accessibility.signals.lineHasInlineSuggestion"})}static{this.terminalQuickFix=a.register({name:(0,s.kg)("accessibilitySignals.terminalQuickFix.name","Terminal Quick Fix"),sound:r.quickFixes,legacySoundSettingsKey:"audioCues.terminalQuickFix",legacyAnnouncementSettingsKey:"accessibility.alert.terminalQuickFix",announcementMessage:(0,s.kg)("accessibility.signals.terminalQuickFix","Quick Fix"),settingsKey:"accessibility.signals.terminalQuickFix"})}static{this.onDebugBreak=a.register({name:(0,s.kg)("accessibilitySignals.onDebugBreak.name","Debugger Stopped on Breakpoint"),sound:r.break,legacySoundSettingsKey:"audioCues.onDebugBreak",legacyAnnouncementSettingsKey:"accessibility.alert.onDebugBreak",announcementMessage:(0,s.kg)("accessibility.signals.onDebugBreak","Breakpoint"),settingsKey:"accessibility.signals.onDebugBreak"})}static{this.noInlayHints=a.register({name:(0,s.kg)("accessibilitySignals.noInlayHints","No Inlay Hints on Line"),sound:r.error,legacySoundSettingsKey:"audioCues.noInlayHints",legacyAnnouncementSettingsKey:"accessibility.alert.noInlayHints",announcementMessage:(0,s.kg)("accessibility.signals.noInlayHints","No Inlay Hints"),settingsKey:"accessibility.signals.noInlayHints"})}static{this.taskCompleted=a.register({name:(0,s.kg)("accessibilitySignals.taskCompleted","Task Completed"),sound:r.taskCompleted,legacySoundSettingsKey:"audioCues.taskCompleted",legacyAnnouncementSettingsKey:"accessibility.alert.taskCompleted",announcementMessage:(0,s.kg)("accessibility.signals.taskCompleted","Task Completed"),settingsKey:"accessibility.signals.taskCompleted"})}static{this.taskFailed=a.register({name:(0,s.kg)("accessibilitySignals.taskFailed","Task Failed"),sound:r.taskFailed,legacySoundSettingsKey:"audioCues.taskFailed",legacyAnnouncementSettingsKey:"accessibility.alert.taskFailed",announcementMessage:(0,s.kg)("accessibility.signals.taskFailed","Task Failed"),settingsKey:"accessibility.signals.taskFailed"})}static{this.terminalCommandFailed=a.register({name:(0,s.kg)("accessibilitySignals.terminalCommandFailed","Terminal Command Failed"),sound:r.error,legacySoundSettingsKey:"audioCues.terminalCommandFailed",legacyAnnouncementSettingsKey:"accessibility.alert.terminalCommandFailed",announcementMessage:(0,s.kg)("accessibility.signals.terminalCommandFailed","Command Failed"),settingsKey:"accessibility.signals.terminalCommandFailed"})}static{this.terminalCommandSucceeded=a.register({name:(0,s.kg)("accessibilitySignals.terminalCommandSucceeded","Terminal Command Succeeded"),sound:r.success,announcementMessage:(0,s.kg)("accessibility.signals.terminalCommandSucceeded","Command Succeeded"),settingsKey:"accessibility.signals.terminalCommandSucceeded"})}static{this.terminalBell=a.register({name:(0,s.kg)("accessibilitySignals.terminalBell","Terminal Bell"),sound:r.terminalBell,legacySoundSettingsKey:"audioCues.terminalBell",legacyAnnouncementSettingsKey:"accessibility.alert.terminalBell",announcementMessage:(0,s.kg)("accessibility.signals.terminalBell","Terminal Bell"),settingsKey:"accessibility.signals.terminalBell"})}static{this.notebookCellCompleted=a.register({name:(0,s.kg)("accessibilitySignals.notebookCellCompleted","Notebook Cell Completed"),sound:r.taskCompleted,legacySoundSettingsKey:"audioCues.notebookCellCompleted",legacyAnnouncementSettingsKey:"accessibility.alert.notebookCellCompleted",announcementMessage:(0,s.kg)("accessibility.signals.notebookCellCompleted","Notebook Cell Completed"),settingsKey:"accessibility.signals.notebookCellCompleted"})}static{this.notebookCellFailed=a.register({name:(0,s.kg)("accessibilitySignals.notebookCellFailed","Notebook Cell Failed"),sound:r.taskFailed,legacySoundSettingsKey:"audioCues.notebookCellFailed",legacyAnnouncementSettingsKey:"accessibility.alert.notebookCellFailed",announcementMessage:(0,s.kg)("accessibility.signals.notebookCellFailed","Notebook Cell Failed"),settingsKey:"accessibility.signals.notebookCellFailed"})}static{this.diffLineInserted=a.register({name:(0,s.kg)("accessibilitySignals.diffLineInserted","Diff Line Inserted"),sound:r.diffLineInserted,legacySoundSettingsKey:"audioCues.diffLineInserted",settingsKey:"accessibility.signals.diffLineInserted"})}static{this.diffLineDeleted=a.register({name:(0,s.kg)("accessibilitySignals.diffLineDeleted","Diff Line Deleted"),sound:r.diffLineDeleted,legacySoundSettingsKey:"audioCues.diffLineDeleted",settingsKey:"accessibility.signals.diffLineDeleted"})}static{this.diffLineModified=a.register({name:(0,s.kg)("accessibilitySignals.diffLineModified","Diff Line Modified"),sound:r.diffLineModified,legacySoundSettingsKey:"audioCues.diffLineModified",settingsKey:"accessibility.signals.diffLineModified"})}static{this.chatRequestSent=a.register({name:(0,s.kg)("accessibilitySignals.chatRequestSent","Chat Request Sent"),sound:r.chatRequestSent,legacySoundSettingsKey:"audioCues.chatRequestSent",legacyAnnouncementSettingsKey:"accessibility.alert.chatRequestSent",announcementMessage:(0,s.kg)("accessibility.signals.chatRequestSent","Chat Request Sent"),settingsKey:"accessibility.signals.chatRequestSent"})}static{this.chatResponseReceived=a.register({name:(0,s.kg)("accessibilitySignals.chatResponseReceived","Chat Response Received"),legacySoundSettingsKey:"audioCues.chatResponseReceived",sound:{randomOneOf:[r.chatResponseReceived1,r.chatResponseReceived2,r.chatResponseReceived3,r.chatResponseReceived4]},settingsKey:"accessibility.signals.chatResponseReceived"})}static{this.progress=a.register({name:(0,s.kg)("accessibilitySignals.progress","Progress"),sound:r.progress,legacySoundSettingsKey:"audioCues.chatResponsePending",legacyAnnouncementSettingsKey:"accessibility.alert.progress",announcementMessage:(0,s.kg)("accessibility.signals.progress","Progress"),settingsKey:"accessibility.signals.progress"})}static{this.clear=a.register({name:(0,s.kg)("accessibilitySignals.clear","Clear"),sound:r.clear,legacySoundSettingsKey:"audioCues.clear",legacyAnnouncementSettingsKey:"accessibility.alert.clear",announcementMessage:(0,s.kg)("accessibility.signals.clear","Clear"),settingsKey:"accessibility.signals.clear"})}static{this.save=a.register({name:(0,s.kg)("accessibilitySignals.save","Save"),sound:r.save,legacySoundSettingsKey:"audioCues.save",legacyAnnouncementSettingsKey:"accessibility.alert.save",announcementMessage:(0,s.kg)("accessibility.signals.save","Save"),settingsKey:"accessibility.signals.save"})}static{this.format=a.register({name:(0,s.kg)("accessibilitySignals.format","Format"),sound:r.format,legacySoundSettingsKey:"audioCues.format",legacyAnnouncementSettingsKey:"accessibility.alert.format",announcementMessage:(0,s.kg)("accessibility.signals.format","Format"),settingsKey:"accessibility.signals.format"})}static{this.voiceRecordingStarted=a.register({name:(0,s.kg)("accessibilitySignals.voiceRecordingStarted","Voice Recording Started"),sound:r.voiceRecordingStarted,legacySoundSettingsKey:"audioCues.voiceRecordingStarted",settingsKey:"accessibility.signals.voiceRecordingStarted"})}static{this.voiceRecordingStopped=a.register({name:(0,s.kg)("accessibilitySignals.voiceRecordingStopped","Voice Recording Stopped"),sound:r.voiceRecordingStopped,legacySoundSettingsKey:"audioCues.voiceRecordingStopped",settingsKey:"accessibility.signals.voiceRecordingStopped"})}}},73983:(e,t,i)=>{"use strict";function s(e){return e&&"object"===typeof e&&"string"===typeof e.original&&"string"===typeof e.value}function n(e){return!!e&&void 0!==e.condition}i.d(t,{N:()=>n,f:()=>s})},57629:(e,t,i)=>{"use strict";i.d(t,{oq:()=>I,rr:()=>O,rN:()=>F,Ot:()=>A,$u:()=>k});var s=i(8597),n=i(72962),r=i(5646),o=i(89506),a=i(36921),l=i(83619),c=i(5662),h=i(98067),d=i(78209),u=i(27195),g=i(73983),p=i(32848),m=i(47508),f=i(63591),_=i(98031),v=i(58591),C=i(9711),b=i(47612),E=i(25689),S=i(86723),y=i(631),w=i(66261),L=i(19070),R=i(253),T=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},x=function(e,t){return function(i,s){t(i,s,e)}};function k(e,t,i,n){let r,o,a;if(Array.isArray(e))a=e,r=t,o=i;else{const s=t;a=e.getActions(s),r=i,o=n}const l=s.Di.getInstance();N(a,r,l.keyStatus.altKey||(h.uF||h.j9)&&l.keyStatus.shiftKey,o?e=>e===o:e=>"navigation"===e)}function A(e,t,i,s,n,r){let o,a,l,c,h;if(Array.isArray(e))h=e,o=t,a=i,l=s,c=n;else{const d=t;h=e.getActions(d),o=i,a=s,l=n,c=r}N(h,o,!1,"string"===typeof a?e=>e===a:a,l,c)}function N(e,t,i,s=e=>"navigation"===e,n=()=>!1,r=!1){let o,l;Array.isArray(t)?(o=t,l=t):(o=t.primary,l=t.secondary);const c=new Set;for(const[h,d]of e){let e;s(h)?(e=o,e.length>0&&r&&e.push(new a.wv)):(e=l,e.length>0&&e.push(new a.wv));for(let t of d){i&&(t=t instanceof u.Xe&&t.alt?t.alt:t);const s=e.push(t);t instanceof a.YH&&c.add({group:h,action:t,index:s-1})}}for(const{group:a,action:h,index:d}of c){const e=s(a)?o:l,t=h.actions;n(h,a,e.length)&&e.splice(d,1,...t)}}let I=class extends r.Z4{constructor(e,t,i,n,r,o,a,l){super(void 0,e,{icon:!(!e.class&&!e.item.icon),label:!e.class&&!e.item.icon,draggable:t?.draggable,keybinding:t?.keybinding,hoverDelegate:t?.hoverDelegate}),this._options=t,this._keybindingService=i,this._notificationService=n,this._contextKeyService=r,this._themeService=o,this._contextMenuService=a,this._accessibilityService=l,this._wantsAltCommand=!1,this._itemClassDispose=this._register(new c.HE),this._altKey=s.Di.getInstance()}get _menuItemAction(){return this._action}get _commandAction(){return this._wantsAltCommand&&this._menuItemAction.alt||this._menuItemAction}async onClick(e){e.preventDefault(),e.stopPropagation();try{await this.actionRunner.run(this._commandAction,this._context)}catch(t){this._notificationService.error(t)}}render(e){if(super.render(e),e.classList.add("menu-entry"),this.options.icon&&this._updateItemClass(this._menuItemAction.item),this._menuItemAction.alt){let t=!1;const i=()=>{const e=!!this._menuItemAction.alt?.enabled&&(!this._accessibilityService.isMotionReduced()||t)&&(this._altKey.keyStatus.altKey||this._altKey.keyStatus.shiftKey&&t);e!==this._wantsAltCommand&&(this._wantsAltCommand=e,this.updateLabel(),this.updateTooltip(),this.updateClass())};this._register(this._altKey.event(i)),this._register((0,s.ko)(e,"mouseleave",(e=>{t=!1,i()}))),this._register((0,s.ko)(e,"mouseenter",(e=>{t=!0,i()}))),i()}}updateLabel(){this.options.label&&this.label&&(this.label.textContent=this._commandAction.label)}getTooltip(){const e=this._keybindingService.lookupKeybinding(this._commandAction.id,this._contextKeyService),t=e&&e.getLabel(),i=this._commandAction.tooltip||this._commandAction.label;let s=t?(0,d.kg)("titleAndKb","{0} ({1})",i,t):i;if(!this._wantsAltCommand&&this._menuItemAction.alt?.enabled){const e=this._menuItemAction.alt.tooltip||this._menuItemAction.alt.label,t=this._keybindingService.lookupKeybinding(this._menuItemAction.alt.id,this._contextKeyService),i=t&&t.getLabel(),n=i?(0,d.kg)("titleAndKb","{0} ({1})",e,i):e;s=(0,d.kg)("titleAndKbAndAlt","{0}\n[{1}] {2}",s,l.Of.modifierLabels[h.OS].altKey,n)}return s}updateClass(){this.options.icon&&(this._commandAction!==this._menuItemAction?this._menuItemAction.alt&&this._updateItemClass(this._menuItemAction.alt.item):this._updateItemClass(this._menuItemAction.item))}_updateItemClass(e){this._itemClassDispose.value=void 0;const{element:t,label:i}=this;if(!t||!i)return;const n=this._commandAction.checked&&(0,g.N)(e.toggled)&&e.toggled.icon?e.toggled.icon:e.icon;if(n)if(E.L.isThemeIcon(n)){const e=E.L.asClassNameArray(n);i.classList.add(...e),this._itemClassDispose.value=(0,c.s)((()=>{i.classList.remove(...e)}))}else i.style.backgroundImage=(0,S.HD)(this._themeService.getColorTheme().type)?(0,s.Tf)(n.dark):(0,s.Tf)(n.light),i.classList.add("icon"),this._itemClassDispose.value=(0,c.qE)((0,c.s)((()=>{i.style.backgroundImage="",i.classList.remove("icon")})),this._themeService.onDidColorThemeChange((()=>{this.updateClass()})))}};I=T([x(2,_.b),x(3,v.Ot),x(4,p.fN),x(5,b.Gy),x(6,m.Z),x(7,R.j)],I);class O extends I{render(e){this.options.label=!0,this.options.icon=!1,super.render(e),e.classList.add("text-only"),e.classList.toggle("use-comma",this._options?.useComma??!1)}updateLabel(){const e=this._keybindingService.lookupKeybinding(this._action.id,this._contextKeyService);if(!e)return super.updateLabel();if(this.label){const t=O._symbolPrintEnter(e);this._options?.conversational?this.label.textContent=(0,d.kg)({key:"content2",comment:['A label with keybindg like "ESC to dismiss"']},"{1} to {0}",this._action.label,t):this.label.textContent=(0,d.kg)({key:"content",comment:["A label","A keybinding"]},"{0} ({1})",this._action.label,t)}}static _symbolPrintEnter(e){return e.getLabel()?.replace(/\benter\b/gi,"\u23ce").replace(/\bEscape\b/gi,"Esc")}}let D=class extends o.d{constructor(e,t,i,s,n){const r={...t,menuAsChild:t?.menuAsChild??!1,classNames:t?.classNames??(E.L.isThemeIcon(e.item.icon)?E.L.asClassName(e.item.icon):void 0),keybindingProvider:t?.keybindingProvider??(e=>i.lookupKeybinding(e.id))};super(e,{getActions:()=>e.actions},s,r),this._keybindingService=i,this._contextMenuService=s,this._themeService=n}render(e){super.render(e),(0,y.j)(this.element),e.classList.add("menu-entry");const t=this._action,{icon:i}=t.item;if(i&&!E.L.isThemeIcon(i)){this.element.classList.add("icon");const e=()=>{this.element&&(this.element.style.backgroundImage=(0,S.HD)(this._themeService.getColorTheme().type)?(0,s.Tf)(i.dark):(0,s.Tf)(i.light))};e(),this._register(this._themeService.onDidColorThemeChange((()=>{e()})))}}};D=T([x(2,_.b),x(3,m.Z),x(4,b.Gy)],D);let M=class extends r.EH{constructor(e,t,i,s,n,r,l,c){let h;super(null,e),this._keybindingService=i,this._notificationService=s,this._contextMenuService=n,this._menuService=r,this._instaService=l,this._storageService=c,this._container=null,this._options=t,this._storageKey=`${e.item.submenu.id}_lastActionId`;const d=t?.persistLastActionId?c.get(this._storageKey,1):void 0;d&&(h=e.actions.find((e=>d===e.id))),h||(h=e.actions[0]),this._defaultAction=this._instaService.createInstance(I,h,{keybinding:this._getDefaultActionKeybindingLabel(h)});const g={keybindingProvider:e=>this._keybindingService.lookupKeybinding(e.id),...t,menuAsChild:t?.menuAsChild??!0,classNames:t?.classNames??["codicon","codicon-chevron-down"],actionRunner:t?.actionRunner??new a.LN};this._dropdown=new o.d(e,e.actions,this._contextMenuService,g),this._register(this._dropdown.actionRunner.onDidRun((e=>{e.action instanceof u.Xe&&this.update(e.action)})))}update(e){this._options?.persistLastActionId&&this._storageService.store(this._storageKey,e.id,1,1),this._defaultAction.dispose(),this._defaultAction=this._instaService.createInstance(I,e,{keybinding:this._getDefaultActionKeybindingLabel(e)}),this._defaultAction.actionRunner=new class extends a.LN{async runAction(e,t){await e.run(void 0)}},this._container&&this._defaultAction.render((0,s.Hs)(this._container,(0,s.$)(".action-container")))}_getDefaultActionKeybindingLabel(e){let t;if(this._options?.renderKeybindingWithDefaultActionLabel){const i=this._keybindingService.lookupKeybinding(e.id);i&&(t=`(${i.getLabel()})`)}return t}setActionContext(e){super.setActionContext(e),this._defaultAction.setActionContext(e),this._dropdown.setActionContext(e)}render(e){this._container=e,super.render(this._container),this._container.classList.add("monaco-dropdown-with-default");const t=(0,s.$)(".action-container");this._defaultAction.render((0,s.BC)(this._container,t)),this._register((0,s.ko)(t,s.Bx.KEY_DOWN,(e=>{const t=new n.Z(e);t.equals(17)&&(this._defaultAction.element.tabIndex=-1,this._dropdown.focus(),t.stopPropagation())})));const i=(0,s.$)(".dropdown-action-container");this._dropdown.render((0,s.BC)(this._container,i)),this._register((0,s.ko)(i,s.Bx.KEY_DOWN,(e=>{const t=new n.Z(e);t.equals(15)&&(this._defaultAction.element.tabIndex=0,this._dropdown.setFocusable(!1),this._defaultAction.element?.focus(),t.stopPropagation())})))}focus(e){e?this._dropdown.focus():(this._defaultAction.element.tabIndex=0,this._defaultAction.element.focus())}blur(){this._defaultAction.element.tabIndex=-1,this._dropdown.blur(),this._container.blur()}setFocusable(e){e?this._defaultAction.element.tabIndex=0:(this._defaultAction.element.tabIndex=-1,this._dropdown.setFocusable(!1))}dispose(){this._defaultAction.dispose(),this._dropdown.dispose(),super.dispose()}};M=T([x(2,_.b),x(3,v.Ot),x(4,m.Z),x(5,u.ez),x(6,f._Y),x(7,C.CS)],M);let P=class extends r.XF{constructor(e,t){super(null,e,e.actions.map((e=>({text:e.id===a.wv.ID?"\u2500\u2500\u2500\u2500\u2500\u2500\u2500\u2500\u2500":e.label,isDisabled:!e.enabled}))),0,t,L.RE,{ariaLabel:e.tooltip,optionsAsChildren:!0}),this.select(Math.max(0,e.actions.findIndex((e=>e.checked))))}render(e){super.render(e),e.style.borderColor=(0,w.GuP)(w.HcB)}runAction(e,t){const i=this.action.actions[t];i&&this.actionRunner.run(i)}};function F(e,t,i){return t instanceof u.Xe?e.createInstance(I,t,i):t instanceof u.nI?t.item.isSelection?e.createInstance(P,t):t.item.rememberDefaultAction?e.createInstance(M,t,{...i,persistLastActionId:!0}):e.createInstance(D,t,i):void 0}P=T([x(1,m.l)],P)},65644:(e,t,i)=>{"use strict";i.d(t,{m:()=>N,p:()=>A});var s=i(8597),n=i(47358),r=i(11799),o=i(89506),a=i(36921),l=i(10350),c=i(25689),h=i(41234),d=i(5662),u=i(78209),g=i(42904);class p extends d.jG{constructor(e,t,i={orientation:0}){super(),this.submenuActionViewItems=[],this.hasSecondaryActions=!1,this._onDidChangeDropdownVisibility=this._register(new h._B),this.onDidChangeDropdownVisibility=this._onDidChangeDropdownVisibility.event,this.disposables=this._register(new d.Cm),i.hoverDelegate=i.hoverDelegate??this._register((0,g.bW)()),this.options=i,this.toggleMenuAction=this._register(new m((()=>this.toggleMenuActionViewItem?.show()),i.toggleMenuTitle)),this.element=document.createElement("div"),this.element.className="monaco-toolbar",e.appendChild(this.element),this.actionBar=this._register(new r.E(this.element,{orientation:i.orientation,ariaLabel:i.ariaLabel,actionRunner:i.actionRunner,allowContextMenu:i.allowContextMenu,highlightToggledItems:i.highlightToggledItems,hoverDelegate:i.hoverDelegate,actionViewItemProvider:(e,s)=>{if(e.id===m.ID)return this.toggleMenuActionViewItem=new o.d(e,e.menuActions,t,{actionViewItemProvider:this.options.actionViewItemProvider,actionRunner:this.actionRunner,keybindingProvider:this.options.getKeyBinding,classNames:c.L.asClassNameArray(i.moreIcon??l.W.toolBarMore),anchorAlignmentProvider:this.options.anchorAlignmentProvider,menuAsChild:!!this.options.renderDropdownAsChildElement,skipTelemetry:this.options.skipTelemetry,isMenu:!0,hoverDelegate:this.options.hoverDelegate}),this.toggleMenuActionViewItem.setActionContext(this.actionBar.context),this.disposables.add(this._onDidChangeDropdownVisibility.add(this.toggleMenuActionViewItem.onDidChangeVisibility)),this.toggleMenuActionViewItem;if(i.actionViewItemProvider){const t=i.actionViewItemProvider(e,s);if(t)return t}if(e instanceof a.YH){const i=new o.d(e,e.actions,t,{actionViewItemProvider:this.options.actionViewItemProvider,actionRunner:this.actionRunner,keybindingProvider:this.options.getKeyBinding,classNames:e.class,anchorAlignmentProvider:this.options.anchorAlignmentProvider,menuAsChild:!!this.options.renderDropdownAsChildElement,skipTelemetry:this.options.skipTelemetry,hoverDelegate:this.options.hoverDelegate});return i.setActionContext(this.actionBar.context),this.submenuActionViewItems.push(i),this.disposables.add(this._onDidChangeDropdownVisibility.add(i.onDidChangeVisibility)),i}}}))}set actionRunner(e){this.actionBar.actionRunner=e}get actionRunner(){return this.actionBar.actionRunner}getElement(){return this.element}getItemAction(e){return this.actionBar.getAction(e)}setActions(e,t){this.clear();const i=e?e.slice(0):[];this.hasSecondaryActions=!!(t&&t.length>0),this.hasSecondaryActions&&t&&(this.toggleMenuAction.menuActions=t.slice(0),i.push(this.toggleMenuAction)),i.forEach((e=>{this.actionBar.push(e,{icon:this.options.icon??!0,label:this.options.label??!1,keybinding:this.getKeybindingLabel(e)})}))}getKeybindingLabel(e){const t=this.options.getKeyBinding?.(e);return t?.getLabel()??void 0}clear(){this.submenuActionViewItems=[],this.disposables.clear(),this.actionBar.clear()}dispose(){this.clear(),this.disposables.dispose(),super.dispose()}}class m extends a.rc{static{this.ID="toolbar.toggle.more"}constructor(e,t){t=t||u.kg("moreActions","More Actions..."),super(m.ID,t,void 0,!0),this._menuActions=[],this.toggleDropdownMenu=e}async run(){this.toggleDropdownMenu()}get menuActions(){return this._menuActions}set menuActions(e){this._menuActions=e}}var f=i(25890),_=i(48495),v=i(64383),C=i(42522),b=i(57629),E=i(27195),S=i(60858),y=i(50091),w=i(32848),L=i(47508),R=i(98031),T=i(90651),x=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},k=function(e,t){return function(i,s){t(i,s,e)}};let A=class extends p{constructor(e,t,i,s,n,r,o,a){super(e,n,{getKeyBinding:e=>r.lookupKeybinding(e.id)??void 0,...t,allowContextMenu:!0,skipTelemetry:"string"===typeof t?.telemetrySource}),this._options=t,this._menuService=i,this._contextKeyService=s,this._contextMenuService=n,this._keybindingService=r,this._commandService=o,this._sessionDisposables=this._store.add(new d.Cm);const l=t?.telemetrySource;l&&this._store.add(this.actionBar.onDidRun((e=>a.publicLog2("workbenchActionExecuted",{id:e.action.id,from:l}))))}setActions(e,t=[],i){this._sessionDisposables.clear();const r=e.slice(),o=t.slice(),l=[];let c=0;const h=[];let d=!1;if(-1!==this._options?.hiddenItemStrategy)for(let s=0;se?.id))),t=this._options.overflowBehavior.maxItems-e.size;let i=0;for(let s=0;s=t&&(r[s]=void 0,h[s]=n))}}(0,f.SK)(r),(0,f.SK)(h),super.setActions(r,a.wv.join(h,o)),(l.length>0||r.length>0)&&this._sessionDisposables.add((0,s.ko)(this.getElement(),"contextmenu",(e=>{const t=new n.P((0,s.zk)(this.getElement()),e),r=this.getItemAction(t.target);if(!r)return;t.preventDefault(),t.stopPropagation();const o=[];if(r instanceof E.Xe&&r.menuKeybinding)o.push(r.menuKeybinding);else if(!(r instanceof E.nI||r instanceof m)){const e=!!this._keybindingService.lookupKeybinding(r.id);o.push((0,S.D)(this._commandService,this._keybindingService,r.id,void 0,e))}if(l.length>0){let e=!1;if(1===c&&0===this._options?.hiddenItemStrategy){e=!0;for(let e=0;ethis._menuService.resetHiddenStates(i)}))),0!==h.length&&this._contextMenuService.showContextMenu({getAnchor:()=>t,getActions:()=>h,menuId:this._options?.contextMenu,menuActionOptions:{renderShortTitle:!0,...this._options?.menuOptions},skipTelemetry:"string"===typeof this._options?.telemetrySource,contextKeyService:this._contextKeyService})})))}};A=x([k(2,E.ez),k(3,w.fN),k(4,L.Z),k(5,R.b),k(6,y.d),k(7,T.k)],A);let N=class extends A{constructor(e,t,i,s,n,r,o,a,l){super(e,{resetMenu:t,...i},s,n,r,o,a,l),this._onDidChangeMenuItems=this._store.add(new h.vl),this.onDidChangeMenuItems=this._onDidChangeMenuItems.event;const c=this._store.add(s.createMenu(t,n,{emitEventsForSubmenuChanges:!0})),d=()=>{const t=[],s=[];(0,b.Ot)(c,i?.menuOptions,{primary:t,secondary:s},i?.toolbarOptions?.primaryGroup,i?.toolbarOptions?.shouldInlineSubmenu,i?.toolbarOptions?.useSeparatorsInPrimaryActions),e.classList.toggle("has-no-actions",0===t.length&&0===s.length),super.setActions(t,s)};this._store.add(c.onDidChange((()=>{d(),this._onDidChangeMenuItems.fire(this)}))),d()}setActions(){throw new v.D7("This toolbar is populated from a menu.")}};N=x([k(3,E.ez),k(4,w.fN),k(5,L.Z),k(6,R.b),k(7,y.d),k(8,T.k)],N)},27195:(e,t,i)=>{"use strict";i.d(t,{D8:()=>_,L:()=>y,Xe:()=>S,ZG:()=>b,ez:()=>v,i1:()=>f,is:()=>m,nI:()=>E,ug:()=>w});var s,n=i(36921),r=i(25689),o=i(41234),a=i(5662),l=i(58925),c=i(50091),h=i(32848),d=i(63591),u=i(59261),g=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},p=function(e,t){return function(i,s){t(i,s,e)}};function m(e){return void 0!==e.command}function f(e){return void 0!==e.submenu}class _{static{this._instances=new Map}static{this.CommandPalette=new _("CommandPalette")}static{this.DebugBreakpointsContext=new _("DebugBreakpointsContext")}static{this.DebugCallStackContext=new _("DebugCallStackContext")}static{this.DebugConsoleContext=new _("DebugConsoleContext")}static{this.DebugVariablesContext=new _("DebugVariablesContext")}static{this.NotebookVariablesContext=new _("NotebookVariablesContext")}static{this.DebugHoverContext=new _("DebugHoverContext")}static{this.DebugWatchContext=new _("DebugWatchContext")}static{this.DebugToolBar=new _("DebugToolBar")}static{this.DebugToolBarStop=new _("DebugToolBarStop")}static{this.DebugCallStackToolbar=new _("DebugCallStackToolbar")}static{this.DebugCreateConfiguration=new _("DebugCreateConfiguration")}static{this.EditorContext=new _("EditorContext")}static{this.SimpleEditorContext=new _("SimpleEditorContext")}static{this.EditorContent=new _("EditorContent")}static{this.EditorLineNumberContext=new _("EditorLineNumberContext")}static{this.EditorContextCopy=new _("EditorContextCopy")}static{this.EditorContextPeek=new _("EditorContextPeek")}static{this.EditorContextShare=new _("EditorContextShare")}static{this.EditorTitle=new _("EditorTitle")}static{this.EditorTitleRun=new _("EditorTitleRun")}static{this.EditorTitleContext=new _("EditorTitleContext")}static{this.EditorTitleContextShare=new _("EditorTitleContextShare")}static{this.EmptyEditorGroup=new _("EmptyEditorGroup")}static{this.EmptyEditorGroupContext=new _("EmptyEditorGroupContext")}static{this.EditorTabsBarContext=new _("EditorTabsBarContext")}static{this.EditorTabsBarShowTabsSubmenu=new _("EditorTabsBarShowTabsSubmenu")}static{this.EditorTabsBarShowTabsZenModeSubmenu=new _("EditorTabsBarShowTabsZenModeSubmenu")}static{this.EditorActionsPositionSubmenu=new _("EditorActionsPositionSubmenu")}static{this.ExplorerContext=new _("ExplorerContext")}static{this.ExplorerContextShare=new _("ExplorerContextShare")}static{this.ExtensionContext=new _("ExtensionContext")}static{this.GlobalActivity=new _("GlobalActivity")}static{this.CommandCenter=new _("CommandCenter")}static{this.CommandCenterCenter=new _("CommandCenterCenter")}static{this.LayoutControlMenuSubmenu=new _("LayoutControlMenuSubmenu")}static{this.LayoutControlMenu=new _("LayoutControlMenu")}static{this.MenubarMainMenu=new _("MenubarMainMenu")}static{this.MenubarAppearanceMenu=new _("MenubarAppearanceMenu")}static{this.MenubarDebugMenu=new _("MenubarDebugMenu")}static{this.MenubarEditMenu=new _("MenubarEditMenu")}static{this.MenubarCopy=new _("MenubarCopy")}static{this.MenubarFileMenu=new _("MenubarFileMenu")}static{this.MenubarGoMenu=new _("MenubarGoMenu")}static{this.MenubarHelpMenu=new _("MenubarHelpMenu")}static{this.MenubarLayoutMenu=new _("MenubarLayoutMenu")}static{this.MenubarNewBreakpointMenu=new _("MenubarNewBreakpointMenu")}static{this.PanelAlignmentMenu=new _("PanelAlignmentMenu")}static{this.PanelPositionMenu=new _("PanelPositionMenu")}static{this.ActivityBarPositionMenu=new _("ActivityBarPositionMenu")}static{this.MenubarPreferencesMenu=new _("MenubarPreferencesMenu")}static{this.MenubarRecentMenu=new _("MenubarRecentMenu")}static{this.MenubarSelectionMenu=new _("MenubarSelectionMenu")}static{this.MenubarShare=new _("MenubarShare")}static{this.MenubarSwitchEditorMenu=new _("MenubarSwitchEditorMenu")}static{this.MenubarSwitchGroupMenu=new _("MenubarSwitchGroupMenu")}static{this.MenubarTerminalMenu=new _("MenubarTerminalMenu")}static{this.MenubarViewMenu=new _("MenubarViewMenu")}static{this.MenubarHomeMenu=new _("MenubarHomeMenu")}static{this.OpenEditorsContext=new _("OpenEditorsContext")}static{this.OpenEditorsContextShare=new _("OpenEditorsContextShare")}static{this.ProblemsPanelContext=new _("ProblemsPanelContext")}static{this.SCMInputBox=new _("SCMInputBox")}static{this.SCMChangesSeparator=new _("SCMChangesSeparator")}static{this.SCMChangesContext=new _("SCMChangesContext")}static{this.SCMIncomingChanges=new _("SCMIncomingChanges")}static{this.SCMIncomingChangesContext=new _("SCMIncomingChangesContext")}static{this.SCMIncomingChangesSetting=new _("SCMIncomingChangesSetting")}static{this.SCMOutgoingChanges=new _("SCMOutgoingChanges")}static{this.SCMOutgoingChangesContext=new _("SCMOutgoingChangesContext")}static{this.SCMOutgoingChangesSetting=new _("SCMOutgoingChangesSetting")}static{this.SCMIncomingChangesAllChangesContext=new _("SCMIncomingChangesAllChangesContext")}static{this.SCMIncomingChangesHistoryItemContext=new _("SCMIncomingChangesHistoryItemContext")}static{this.SCMOutgoingChangesAllChangesContext=new _("SCMOutgoingChangesAllChangesContext")}static{this.SCMOutgoingChangesHistoryItemContext=new _("SCMOutgoingChangesHistoryItemContext")}static{this.SCMChangeContext=new _("SCMChangeContext")}static{this.SCMResourceContext=new _("SCMResourceContext")}static{this.SCMResourceContextShare=new _("SCMResourceContextShare")}static{this.SCMResourceFolderContext=new _("SCMResourceFolderContext")}static{this.SCMResourceGroupContext=new _("SCMResourceGroupContext")}static{this.SCMSourceControl=new _("SCMSourceControl")}static{this.SCMSourceControlInline=new _("SCMSourceControlInline")}static{this.SCMSourceControlTitle=new _("SCMSourceControlTitle")}static{this.SCMHistoryTitle=new _("SCMHistoryTitle")}static{this.SCMTitle=new _("SCMTitle")}static{this.SearchContext=new _("SearchContext")}static{this.SearchActionMenu=new _("SearchActionContext")}static{this.StatusBarWindowIndicatorMenu=new _("StatusBarWindowIndicatorMenu")}static{this.StatusBarRemoteIndicatorMenu=new _("StatusBarRemoteIndicatorMenu")}static{this.StickyScrollContext=new _("StickyScrollContext")}static{this.TestItem=new _("TestItem")}static{this.TestItemGutter=new _("TestItemGutter")}static{this.TestProfilesContext=new _("TestProfilesContext")}static{this.TestMessageContext=new _("TestMessageContext")}static{this.TestMessageContent=new _("TestMessageContent")}static{this.TestPeekElement=new _("TestPeekElement")}static{this.TestPeekTitle=new _("TestPeekTitle")}static{this.TestCallStack=new _("TestCallStack")}static{this.TouchBarContext=new _("TouchBarContext")}static{this.TitleBarContext=new _("TitleBarContext")}static{this.TitleBarTitleContext=new _("TitleBarTitleContext")}static{this.TunnelContext=new _("TunnelContext")}static{this.TunnelPrivacy=new _("TunnelPrivacy")}static{this.TunnelProtocol=new _("TunnelProtocol")}static{this.TunnelPortInline=new _("TunnelInline")}static{this.TunnelTitle=new _("TunnelTitle")}static{this.TunnelLocalAddressInline=new _("TunnelLocalAddressInline")}static{this.TunnelOriginInline=new _("TunnelOriginInline")}static{this.ViewItemContext=new _("ViewItemContext")}static{this.ViewContainerTitle=new _("ViewContainerTitle")}static{this.ViewContainerTitleContext=new _("ViewContainerTitleContext")}static{this.ViewTitle=new _("ViewTitle")}static{this.ViewTitleContext=new _("ViewTitleContext")}static{this.CommentEditorActions=new _("CommentEditorActions")}static{this.CommentThreadTitle=new _("CommentThreadTitle")}static{this.CommentThreadActions=new _("CommentThreadActions")}static{this.CommentThreadAdditionalActions=new _("CommentThreadAdditionalActions")}static{this.CommentThreadTitleContext=new _("CommentThreadTitleContext")}static{this.CommentThreadCommentContext=new _("CommentThreadCommentContext")}static{this.CommentTitle=new _("CommentTitle")}static{this.CommentActions=new _("CommentActions")}static{this.CommentsViewThreadActions=new _("CommentsViewThreadActions")}static{this.InteractiveToolbar=new _("InteractiveToolbar")}static{this.InteractiveCellTitle=new _("InteractiveCellTitle")}static{this.InteractiveCellDelete=new _("InteractiveCellDelete")}static{this.InteractiveCellExecute=new _("InteractiveCellExecute")}static{this.InteractiveInputExecute=new _("InteractiveInputExecute")}static{this.InteractiveInputConfig=new _("InteractiveInputConfig")}static{this.ReplInputExecute=new _("ReplInputExecute")}static{this.IssueReporter=new _("IssueReporter")}static{this.NotebookToolbar=new _("NotebookToolbar")}static{this.NotebookStickyScrollContext=new _("NotebookStickyScrollContext")}static{this.NotebookCellTitle=new _("NotebookCellTitle")}static{this.NotebookCellDelete=new _("NotebookCellDelete")}static{this.NotebookCellInsert=new _("NotebookCellInsert")}static{this.NotebookCellBetween=new _("NotebookCellBetween")}static{this.NotebookCellListTop=new _("NotebookCellTop")}static{this.NotebookCellExecute=new _("NotebookCellExecute")}static{this.NotebookCellExecuteGoTo=new _("NotebookCellExecuteGoTo")}static{this.NotebookCellExecutePrimary=new _("NotebookCellExecutePrimary")}static{this.NotebookDiffCellInputTitle=new _("NotebookDiffCellInputTitle")}static{this.NotebookDiffCellMetadataTitle=new _("NotebookDiffCellMetadataTitle")}static{this.NotebookDiffCellOutputsTitle=new _("NotebookDiffCellOutputsTitle")}static{this.NotebookOutputToolbar=new _("NotebookOutputToolbar")}static{this.NotebookOutlineFilter=new _("NotebookOutlineFilter")}static{this.NotebookOutlineActionMenu=new _("NotebookOutlineActionMenu")}static{this.NotebookEditorLayoutConfigure=new _("NotebookEditorLayoutConfigure")}static{this.NotebookKernelSource=new _("NotebookKernelSource")}static{this.BulkEditTitle=new _("BulkEditTitle")}static{this.BulkEditContext=new _("BulkEditContext")}static{this.TimelineItemContext=new _("TimelineItemContext")}static{this.TimelineTitle=new _("TimelineTitle")}static{this.TimelineTitleContext=new _("TimelineTitleContext")}static{this.TimelineFilterSubMenu=new _("TimelineFilterSubMenu")}static{this.AccountsContext=new _("AccountsContext")}static{this.SidebarTitle=new _("SidebarTitle")}static{this.PanelTitle=new _("PanelTitle")}static{this.AuxiliaryBarTitle=new _("AuxiliaryBarTitle")}static{this.AuxiliaryBarHeader=new _("AuxiliaryBarHeader")}static{this.TerminalInstanceContext=new _("TerminalInstanceContext")}static{this.TerminalEditorInstanceContext=new _("TerminalEditorInstanceContext")}static{this.TerminalNewDropdownContext=new _("TerminalNewDropdownContext")}static{this.TerminalTabContext=new _("TerminalTabContext")}static{this.TerminalTabEmptyAreaContext=new _("TerminalTabEmptyAreaContext")}static{this.TerminalStickyScrollContext=new _("TerminalStickyScrollContext")}static{this.WebviewContext=new _("WebviewContext")}static{this.InlineCompletionsActions=new _("InlineCompletionsActions")}static{this.InlineEditsActions=new _("InlineEditsActions")}static{this.InlineEditActions=new _("InlineEditActions")}static{this.NewFile=new _("NewFile")}static{this.MergeInput1Toolbar=new _("MergeToolbar1Toolbar")}static{this.MergeInput2Toolbar=new _("MergeToolbar2Toolbar")}static{this.MergeBaseToolbar=new _("MergeBaseToolbar")}static{this.MergeInputResultToolbar=new _("MergeToolbarResultToolbar")}static{this.InlineSuggestionToolbar=new _("InlineSuggestionToolbar")}static{this.InlineEditToolbar=new _("InlineEditToolbar")}static{this.ChatContext=new _("ChatContext")}static{this.ChatCodeBlock=new _("ChatCodeblock")}static{this.ChatCompareBlock=new _("ChatCompareBlock")}static{this.ChatMessageTitle=new _("ChatMessageTitle")}static{this.ChatExecute=new _("ChatExecute")}static{this.ChatExecuteSecondary=new _("ChatExecuteSecondary")}static{this.ChatInputSide=new _("ChatInputSide")}static{this.AccessibleView=new _("AccessibleView")}static{this.MultiDiffEditorFileToolbar=new _("MultiDiffEditorFileToolbar")}static{this.DiffEditorHunkToolbar=new _("DiffEditorHunkToolbar")}static{this.DiffEditorSelectionToolbar=new _("DiffEditorSelectionToolbar")}constructor(e){if(_._instances.has(e))throw new TypeError(`MenuId with identifier '${e}' already exists. Use MenuId.for(ident) or a unique identifier`);_._instances.set(e,this),this.id=e}}const v=(0,d.u1)("menuService");class C{static{this._all=new Map}static for(e){let t=this._all.get(e);return t||(t=new C(e),this._all.set(e,t)),t}static merge(e){const t=new Set;for(const i of e)i instanceof C&&t.add(i.id);return t}constructor(e){this.id=e,this.has=t=>t===e}}const b=new class{constructor(){this._commands=new Map,this._menuItems=new Map,this._onDidChangeMenu=new o.QT({merge:C.merge}),this.onDidChangeMenu=this._onDidChangeMenu.event}addCommand(e){return this._commands.set(e.id,e),this._onDidChangeMenu.fire(C.for(_.CommandPalette)),(0,a.s)((()=>{this._commands.delete(e.id)&&this._onDidChangeMenu.fire(C.for(_.CommandPalette))}))}getCommand(e){return this._commands.get(e)}getCommands(){const e=new Map;return this._commands.forEach(((t,i)=>e.set(i,t))),e}appendMenuItem(e,t){let i=this._menuItems.get(e);i||(i=new l.w,this._menuItems.set(e,i));const s=i.push(t);return this._onDidChangeMenu.fire(C.for(e)),(0,a.s)((()=>{s(),this._onDidChangeMenu.fire(C.for(e))}))}appendMenuItems(e){const t=new a.Cm;for(const{id:i,item:s}of e)t.add(this.appendMenuItem(i,s));return t}getMenuItems(e){let t;return t=this._menuItems.has(e)?[...this._menuItems.get(e)]:[],e===_.CommandPalette&&this._appendImplicitItems(t),t}_appendImplicitItems(e){const t=new Set;for(const i of e)m(i)&&(t.add(i.command.id),i.alt&&t.add(i.alt.id));this._commands.forEach(((i,s)=>{t.has(s)||e.push({command:i})}))}};class E extends n.YH{constructor(e,t,i){super(`submenuitem.${e.submenu.id}`,"string"===typeof e.title?e.title:e.title.value,i,"submenu"),this.item=e,this.hideActions=t}}let S=s=class{static label(e,t){return t?.renderShortTitle&&e.shortTitle?"string"===typeof e.shortTitle?e.shortTitle:e.shortTitle.value:"string"===typeof e.title?e.title:e.title.value}constructor(e,t,i,n,o,a,l){let c;if(this.hideActions=n,this.menuKeybinding=o,this._commandService=l,this.id=e.id,this.label=s.label(e,i),this.tooltip=("string"===typeof e.tooltip?e.tooltip:e.tooltip?.value)??"",this.enabled=!e.precondition||a.contextMatchesRules(e.precondition),this.checked=void 0,e.toggled){const t=e.toggled.condition?e.toggled:{condition:e.toggled};this.checked=a.contextMatchesRules(t.condition),this.checked&&t.tooltip&&(this.tooltip="string"===typeof t.tooltip?t.tooltip:t.tooltip.value),this.checked&&r.L.isThemeIcon(t.icon)&&(c=t.icon),this.checked&&t.title&&(this.label="string"===typeof t.title?t.title:t.title.value)}c||(c=r.L.isThemeIcon(e.icon)?e.icon:void 0),this.item=e,this.alt=t?new s(t,void 0,i,n,void 0,a,l):void 0,this._options=i,this.class=c&&r.L.asClassName(c)}run(...e){let t=[];return this._options?.arg&&(t=[...t,this._options.arg]),this._options?.shouldForwardArgs&&(t=[...t,...e]),this._commandService.executeCommand(this.id,...t)}};S=s=g([p(5,h.fN),p(6,c.d)],S);class y{constructor(e){this.desc=e}}function w(e){const t=[],i=new e,{f1:s,menu:n,keybinding:r,...o}=i.desc;if(c.w.getCommand(o.id))throw new Error(`Cannot register two commands with the same id: ${o.id}`);if(t.push(c.w.registerCommand({id:o.id,handler:(e,...t)=>i.run(e,...t),metadata:o.metadata})),Array.isArray(n))for(const a of n)t.push(b.appendMenuItem(a.id,{command:{...o,precondition:null===a.precondition?void 0:o.precondition},...a}));else n&&t.push(b.appendMenuItem(n.id,{command:{...o,precondition:null===n.precondition?void 0:o.precondition},...n}));if(s&&(t.push(b.appendMenuItem(_.CommandPalette,{command:o,when:o.precondition})),t.push(b.addCommand(o))),Array.isArray(r))for(const a of r)t.push(u.f.registerKeybindingRule({...a,id:o.id,when:o.precondition?h.M$.and(o.precondition,a.when):a.when}));else r&&t.push(u.f.registerKeybindingRule({...r,id:o.id,when:o.precondition?h.M$.and(o.precondition,r.when):r.when}));return{dispose(){(0,a.AS)(t)}}}},60858:(e,t,i)=>{"use strict";i.d(t,{$:()=>v,D:()=>w});var s,n,r=i(90766),o=i(41234),a=i(5662),l=i(27195),c=i(50091),h=i(32848),d=i(36921),u=i(9711),g=i(25890),p=i(78209),m=i(98031),f=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},_=function(e,t){return function(i,s){t(i,s,e)}};let v=class{constructor(e,t,i){this._commandService=e,this._keybindingService=t,this._hiddenStates=new C(i)}createMenu(e,t,i){return new S(e,this._hiddenStates,{emitEventsForSubmenuChanges:!1,eventDebounceDelay:50,...i},this._commandService,this._keybindingService,t)}getMenuActions(e,t,i){const s=new S(e,this._hiddenStates,{emitEventsForSubmenuChanges:!1,eventDebounceDelay:50,...i},this._commandService,this._keybindingService,t),n=s.getActions(i);return s.dispose(),n}resetHiddenStates(e){this._hiddenStates.reset(e)}};v=f([_(0,c.d),_(1,m.b),_(2,u.CS)],v);let C=class{static{s=this}static{this._key="menu.hiddenCommands"}constructor(e){this._storageService=e,this._disposables=new a.Cm,this._onDidChange=new o.vl,this.onDidChange=this._onDidChange.event,this._ignoreChangeEvent=!1,this._hiddenByDefaultCache=new Map;try{const t=e.get(s._key,0,"{}");this._data=JSON.parse(t)}catch(t){this._data=Object.create(null)}this._disposables.add(e.onDidChangeValue(0,s._key,this._disposables)((()=>{if(!this._ignoreChangeEvent)try{const t=e.get(s._key,0,"{}");this._data=JSON.parse(t)}catch(t){console.log("FAILED to read storage after UPDATE",t)}this._onDidChange.fire()})))}dispose(){this._onDidChange.dispose(),this._disposables.dispose()}_isHiddenByDefault(e,t){return this._hiddenByDefaultCache.get(`${e.id}/${t}`)??!1}setDefaultState(e,t,i){this._hiddenByDefaultCache.set(`${e.id}/${t}`,i)}isHidden(e,t){const i=this._isHiddenByDefault(e,t),s=this._data[e.id]?.includes(t)??!1;return i?!s:s}updateHidden(e,t,i){this._isHiddenByDefault(e,t)&&(i=!i);const s=this._data[e.id];if(i)if(s){s.indexOf(t)<0&&s.push(t)}else this._data[e.id]=[t];else if(s){const i=s.indexOf(t);i>=0&&(0,g.UH)(s,i),0===s.length&&delete this._data[e.id]}this._persist()}reset(e){if(void 0===e)this._data=Object.create(null),this._persist();else{for(const{id:t}of e)this._data[t]&&delete this._data[t];this._persist()}}_persist(){try{this._ignoreChangeEvent=!0;const e=JSON.stringify(this._data);this._storageService.store(s._key,e,0,0)}finally{this._ignoreChangeEvent=!1}}};C=s=f([_(0,u.CS)],C);class b{constructor(e,t){this._id=e,this._collectContextKeysForSubmenus=t,this._menuGroups=[],this._allMenuIds=new Set,this._structureContextKeys=new Set,this._preconditionContextKeys=new Set,this._toggledContextKeys=new Set,this.refresh()}get allMenuIds(){return this._allMenuIds}get structureContextKeys(){return this._structureContextKeys}get preconditionContextKeys(){return this._preconditionContextKeys}get toggledContextKeys(){return this._toggledContextKeys}refresh(){this._menuGroups.length=0,this._allMenuIds.clear(),this._structureContextKeys.clear(),this._preconditionContextKeys.clear(),this._toggledContextKeys.clear();const e=this._sort(l.ZG.getMenuItems(this._id));let t;for(const i of e){const e=i.group||"";t&&t[0]===e||(t=[e,[]],this._menuGroups.push(t)),t[1].push(i),this._collectContextKeysAndSubmenuIds(i)}this._allMenuIds.add(this._id)}_sort(e){return e}_collectContextKeysAndSubmenuIds(e){if(b._fillInKbExprKeys(e.when,this._structureContextKeys),(0,l.is)(e)){if(e.command.precondition&&b._fillInKbExprKeys(e.command.precondition,this._preconditionContextKeys),e.command.toggled){const t=e.command.toggled.condition||e.command.toggled;b._fillInKbExprKeys(t,this._toggledContextKeys)}}else this._collectContextKeysForSubmenus&&(l.ZG.getMenuItems(e.submenu).forEach(this._collectContextKeysAndSubmenuIds,this),this._allMenuIds.add(e.submenu))}static _fillInKbExprKeys(e,t){if(e)for(const i of e.keys())t.add(i)}}let E=n=class extends b{constructor(e,t,i,s,n,r){super(e,i),this._hiddenStates=t,this._commandService=s,this._keybindingService=n,this._contextKeyService=r,this.refresh()}createActionGroups(e){const t=[];for(const i of this._menuGroups){const[s,r]=i;let o;for(const t of r)if(this._contextKeyService.contextMatchesRules(t.when)){const i=(0,l.is)(t);i&&this._hiddenStates.setDefaultState(this._id,t.command.id,!!t.isHiddenByDefault);const s=y(this._id,i?t.command:t,this._hiddenStates);if(i){const i=w(this._commandService,this._keybindingService,t.command.id,t.when);(o??=[]).push(new l.Xe(t.command,t.alt,e,s,i,this._contextKeyService,this._commandService))}else{const i=new n(t.submenu,this._hiddenStates,this._collectContextKeysForSubmenus,this._commandService,this._keybindingService,this._contextKeyService).createActionGroups(e),r=d.wv.join(...i.map((e=>e[1])));r.length>0&&(o??=[]).push(new l.nI(t,s,r))}}o&&o.length>0&&t.push([s,o])}return t}_sort(e){return e.sort(n._compareMenuItems)}static _compareMenuItems(e,t){const i=e.group,s=t.group;if(i!==s){if(!i)return 1;if(!s)return-1;if("navigation"===i)return-1;if("navigation"===s)return 1;const e=i.localeCompare(s);if(0!==e)return e}const r=e.order||0,o=t.order||0;return ro?1:n._compareTitles((0,l.is)(e)?e.command.title:e.title,(0,l.is)(t)?t.command.title:t.title)}static _compareTitles(e,t){const i="string"===typeof e?e:e.original,s="string"===typeof t?t:t.original;return i.localeCompare(s)}};E=n=f([_(3,c.d),_(4,m.b),_(5,h.fN)],E);let S=class{constructor(e,t,i,s,n,c){this._disposables=new a.Cm,this._menuInfo=new E(e,t,i.emitEventsForSubmenuChanges,s,n,c);const h=new r.uC((()=>{this._menuInfo.refresh(),this._onDidChange.fire({menu:this,isStructuralChange:!0,isEnablementChange:!0,isToggleChange:!0})}),i.eventDebounceDelay);this._disposables.add(h),this._disposables.add(l.ZG.onDidChangeMenu((e=>{for(const t of this._menuInfo.allMenuIds)if(e.has(t)){h.schedule();break}})));const d=this._disposables.add(new a.Cm);this._onDidChange=new o.uI({onWillAddFirstListener:()=>{d.add(c.onDidChangeContext((e=>{const t=e.affectsSome(this._menuInfo.structureContextKeys),i=e.affectsSome(this._menuInfo.preconditionContextKeys),s=e.affectsSome(this._menuInfo.toggledContextKeys);(t||i||s)&&this._onDidChange.fire({menu:this,isStructuralChange:t,isEnablementChange:i,isToggleChange:s})}))),d.add(t.onDidChange((e=>{this._onDidChange.fire({menu:this,isStructuralChange:!0,isEnablementChange:!1,isToggleChange:!1})})))},onDidRemoveLastListener:d.clear.bind(d),delay:i.eventDebounceDelay,merge:e=>{let t=!1,i=!1,s=!1;for(const n of e)if(t=t||n.isStructuralChange,i=i||n.isEnablementChange,s=s||n.isToggleChange,t&&i&&s)break;return{menu:this,isStructuralChange:t,isEnablementChange:i,isToggleChange:s}}}),this.onDidChange=this._onDidChange.event}getActions(e){return this._menuInfo.createActionGroups(e)}dispose(){this._disposables.dispose(),this._onDidChange.dispose()}};function y(e,t,i){const s=(0,l.i1)(t)?t.submenu.id:t.id,n="string"===typeof t.title?t.title:t.title.value,r=(0,d.ih)({id:`hide/${e.id}/${s}`,label:(0,p.kg)("hide.label","Hide '{0}'",n),run(){i.updateHidden(e,s,!0)}}),o=(0,d.ih)({id:`toggle/${e.id}/${s}`,label:n,get checked(){return!i.isHidden(e,s)},run(){i.updateHidden(e,s,!!this.checked)}});return{hide:r,toggle:o,get isHidden(){return!o.checked}}}function w(e,t,i,s=void 0,n=!0){return(0,d.ih)({id:`configureKeybinding/${i}`,label:(0,p.kg)("configure keybinding","Configure Keybinding"),enabled:n,run(){const n=!!!t.lookupKeybinding(i)&&s?s.serialize():void 0;e.executeCommand("workbench.action.openGlobalKeybindings",`@command:${i}`+(n?` +when:${n}`:""))}})}S=f([_(3,c.d),_(4,m.b),_(5,h.fN)],S)},54770:(e,t,i)=>{"use strict";i.d(t,{h:()=>s});const s=(0,i(63591).u1)("clipboardService")},50091:(e,t,i)=>{"use strict";i.d(t,{d:()=>l,w:()=>c});var s=i(41234),n=i(42522),r=i(5662),o=i(58925),a=i(631);const l=(0,i(63591).u1)("commandService"),c=new class{constructor(){this._commands=new Map,this._onDidRegisterCommand=new s.vl,this.onDidRegisterCommand=this._onDidRegisterCommand.event}registerCommand(e,t){if(!e)throw new Error("invalid command");if("string"===typeof e){if(!t)throw new Error("invalid command");return this.registerCommand({id:e,handler:t})}if(e.metadata&&Array.isArray(e.metadata.args)){const t=[];for(const s of e.metadata.args)t.push(s.constraint);const i=e.handler;e.handler=function(e,...s){return(0,a.jx)(s,t),i(e,...s)}}const{id:i}=e;let s=this._commands.get(i);s||(s=new o.w,this._commands.set(i,s));const n=s.unshift(e),l=(0,r.s)((()=>{n();const e=this._commands.get(i);e?.isEmpty()&&this._commands.delete(i)}));return this._onDidRegisterCommand.fire(i),l}registerCommandAlias(e,t){return c.registerCommand(e,((e,...i)=>e.get(l).executeCommand(t,...i)))}getCommand(e){const t=this._commands.get(e);if(t&&!t.isEmpty())return n.f.first(t)}getCommands(){const e=new Map;for(const t of this._commands.keys()){const i=this.getCommand(t);i&&e.set(t,i)}return e}};c.registerCommand("noop",(()=>{}))},84001:(e,t,i)=>{"use strict";i.d(t,{Mo:()=>c,ad:()=>n,gD:()=>l,iB:()=>o,kW:()=>r,pG:()=>s});const s=(0,i(63591).u1)("configurationService");function n(e,t){const i=Object.create(null);for(const s in e)r(i,s,e[s],t);return i}function r(e,t,i,s){const n=t.split("."),r=n.pop();let o=e;for(let l=0;l{"use strict";i.d(t,{Fd:()=>h,Gv:()=>y,rC:()=>S});var s=i(25890),n=i(41234),r=i(631),o=i(78209),a=i(84001),l=i(78748),c=i(46359);const h={Configuration:"base.contributions.configuration"},d={properties:{},patternProperties:{}},u={properties:{},patternProperties:{}},g={properties:{},patternProperties:{}},p={properties:{},patternProperties:{}},m={properties:{},patternProperties:{}},f={properties:{},patternProperties:{}},_="vscode://schemas/settings/resourceLanguage",v=c.O.as(l.F.JSONContribution);const C="\\[([^\\]]+)\\]",b=new RegExp(C,"g"),E=`^(${C})+$`,S=new RegExp(E);function y(e){const t=[];if(S.test(e)){let i=b.exec(e);for(;i?.length;){const s=i[1].trim();s&&t.push(s),i=b.exec(e)}}return(0,s.dM)(t)}const w=new class{constructor(){this.registeredConfigurationDefaults=[],this.overrideIdentifiers=new Set,this._onDidSchemaChange=new n.vl,this._onDidUpdateConfiguration=new n.vl,this.configurationDefaultsOverrides=new Map,this.defaultLanguageConfigurationOverridesNode={id:"defaultOverrides",title:o.kg("defaultLanguageConfigurationOverrides.title","Default Language Configuration Overrides"),properties:{}},this.configurationContributors=[this.defaultLanguageConfigurationOverridesNode],this.resourceLanguageSettingsSchema={properties:{},patternProperties:{},additionalProperties:!0,allowTrailingCommas:!0,allowComments:!0},this.configurationProperties={},this.policyConfigurations=new Map,this.excludedConfigurationProperties={},v.registerSchema(_,this.resourceLanguageSettingsSchema),this.registerOverridePropertyPatternKey()}registerConfiguration(e,t=!0){this.registerConfigurations([e],t)}registerConfigurations(e,t=!0){const i=new Set;this.doRegisterConfigurations(e,t,i),v.registerSchema(_,this.resourceLanguageSettingsSchema),this._onDidSchemaChange.fire(),this._onDidUpdateConfiguration.fire({properties:i})}registerDefaultConfigurations(e){const t=new Set;this.doRegisterDefaultConfigurations(e,t),this._onDidSchemaChange.fire(),this._onDidUpdateConfiguration.fire({properties:t,defaultsOverrides:!0})}doRegisterDefaultConfigurations(e,t){this.registeredConfigurationDefaults.push(...e);const i=[];for(const{overrides:s,source:n}of e)for(const e in s){t.add(e);const r=this.configurationDefaultsOverrides.get(e)??this.configurationDefaultsOverrides.set(e,{configurationDefaultOverrides:[]}).get(e),o=s[e];if(r.configurationDefaultOverrides.push({value:o,source:n}),S.test(e)){const t=this.mergeDefaultConfigurationsForOverrideIdentifier(e,o,n,r.configurationDefaultOverrideValue);if(!t)continue;r.configurationDefaultOverrideValue=t,this.updateDefaultOverrideProperty(e,t,n),i.push(...y(e))}else{const t=this.mergeDefaultConfigurationsForConfigurationProperty(e,o,n,r.configurationDefaultOverrideValue);if(!t)continue;r.configurationDefaultOverrideValue=t;const i=this.configurationProperties[e];i&&(this.updatePropertyDefaultValue(e,i),this.updateSchema(e,i))}}this.doRegisterOverrideIdentifiers(i)}updateDefaultOverrideProperty(e,t,i){const s={type:"object",default:t.value,description:o.kg("defaultLanguageConfiguration.description","Configure settings to be overridden for the {0} language.",(0,a.Mo)(e)),$ref:_,defaultDefaultValue:t.value,source:i,defaultValueSource:i};this.configurationProperties[e]=s,this.defaultLanguageConfigurationOverridesNode.properties[e]=s}mergeDefaultConfigurationsForOverrideIdentifier(e,t,i,s){const n=s?.value||{},o=s?.source??new Map;if(o instanceof Map){for(const e of Object.keys(t)){const s=t[e];if(r.Gv(s)&&(r.b0(n[e])||r.Gv(n[e]))){if(n[e]={...n[e]??{},...s},i)for(const t in s)o.set(`${e}.${t}`,i)}else n[e]=s,i?o.set(e,i):o.delete(e)}return{value:n,source:o}}console.error("objectConfigurationSources is not a Map")}mergeDefaultConfigurationsForConfigurationProperty(e,t,i,s){const n=this.configurationProperties[e],o=s?.value??n?.defaultDefaultValue;let a=i;if(r.Gv(t)&&(void 0!==n&&"object"===n.type||void 0===n&&(r.b0(o)||r.Gv(o)))){if(a=s?.source??new Map,!(a instanceof Map))return void console.error("defaultValueSource is not a Map");for(const s in t)i&&a.set(`${e}.${s}`,i);t={...r.Gv(o)?o:{},...t}}return{value:t,source:a}}registerOverrideIdentifiers(e){this.doRegisterOverrideIdentifiers(e),this._onDidSchemaChange.fire()}doRegisterOverrideIdentifiers(e){for(const t of e)this.overrideIdentifiers.add(t);this.updateOverridePropertyPatternKey()}doRegisterConfigurations(e,t,i){e.forEach((e=>{this.validateAndRegisterProperties(e,t,e.extensionInfo,e.restrictedProperties,void 0,i),this.configurationContributors.push(e),this.registerJSONConfiguration(e)}))}validateAndRegisterProperties(e,t=!0,i,s,n=3,o){n=r.z(e.scope)?n:e.scope;const a=e.properties;if(a)for(const c in a){const e=a[c];t&&L(c,e)?delete a[c]:(e.source=i,e.defaultDefaultValue=a[c].default,this.updatePropertyDefaultValue(c,e),S.test(c)?e.scope=void 0:(e.scope=r.z(e.scope)?n:e.scope,e.restricted=r.z(e.restricted)?!!s?.includes(c):e.restricted),!a[c].hasOwnProperty("included")||a[c].included?(this.configurationProperties[c]=a[c],a[c].policy?.name&&this.policyConfigurations.set(a[c].policy.name,c),!a[c].deprecationMessage&&a[c].markdownDeprecationMessage&&(a[c].deprecationMessage=a[c].markdownDeprecationMessage),o.add(c)):(this.excludedConfigurationProperties[c]=a[c],delete a[c]))}const l=e.allOf;if(l)for(const r of l)this.validateAndRegisterProperties(r,t,i,s,n,o)}getConfigurationProperties(){return this.configurationProperties}getPolicyConfigurations(){return this.policyConfigurations}registerJSONConfiguration(e){const t=e=>{const i=e.properties;if(i)for(const t in i)this.updateSchema(t,i[t]);const s=e.allOf;s?.forEach(t)};t(e)}updateSchema(e,t){switch(d.properties[e]=t,t.scope){case 1:u.properties[e]=t;break;case 2:g.properties[e]=t;break;case 6:p.properties[e]=t;break;case 3:m.properties[e]=t;break;case 4:f.properties[e]=t;break;case 5:f.properties[e]=t,this.resourceLanguageSettingsSchema.properties[e]=t}}updateOverridePropertyPatternKey(){for(const e of this.overrideIdentifiers.values()){const t=`[${e}]`,i={type:"object",description:o.kg("overrideSettings.defaultDescription","Configure editor settings to be overridden for a language."),errorMessage:o.kg("overrideSettings.errorMessage","This setting does not support per-language configuration."),$ref:_};this.updatePropertyDefaultValue(t,i),d.properties[t]=i,u.properties[t]=i,g.properties[t]=i,p.properties[t]=i,m.properties[t]=i,f.properties[t]=i}}registerOverridePropertyPatternKey(){const e={type:"object",description:o.kg("overrideSettings.defaultDescription","Configure editor settings to be overridden for a language."),errorMessage:o.kg("overrideSettings.errorMessage","This setting does not support per-language configuration."),$ref:_};d.patternProperties[E]=e,u.patternProperties[E]=e,g.patternProperties[E]=e,p.patternProperties[E]=e,m.patternProperties[E]=e,f.patternProperties[E]=e,this._onDidSchemaChange.fire()}updatePropertyDefaultValue(e,t){const i=this.configurationDefaultsOverrides.get(e)?.configurationDefaultOverrideValue;let s,n;!i||t.disallowConfigurationDefault&&i.source||(s=i.value,n=i.source),r.b0(s)&&(s=t.defaultDefaultValue,n=void 0),r.b0(s)&&(s=function(e){switch(Array.isArray(e)?e[0]:e){case"boolean":return!1;case"integer":case"number":return 0;case"string":return"";case"array":return[];case"object":return{};default:return null}}(t.type)),t.default=s,t.defaultValueSource=n}};function L(e,t){return e.trim()?S.test(e)?o.kg("config.property.languageDefault","Cannot register '{0}'. This matches property pattern '\\\\[.*\\\\]$' for describing language specific editor settings. Use 'configurationDefaults' contribution.",e):void 0!==w.getConfigurationProperties()[e]?o.kg("config.property.duplicate","Cannot register '{0}'. This property is already registered.",e):t.policy?.name&&void 0!==w.getPolicyConfigurations().get(t.policy?.name)?o.kg("config.policy.duplicate","Cannot register '{0}'. The associated policy {1} is already registered with {2}.",e,t.policy?.name,w.getPolicyConfigurations().get(t.policy?.name)):null:o.kg("config.property.empty","Cannot register an empty property")}c.O.add(h.Configuration,w)},32848:(e,t,i)=>{"use strict";i.d(t,{f1:()=>A,M$:()=>w,fN:()=>K,N1:()=>j,jQ:()=>L,M0:()=>$});var s=i(98067),n=i(91508),r=i(64383),o=i(78209);function a(...e){switch(e.length){case 1:return(0,o.kg)("contextkey.scanner.hint.didYouMean1","Did you mean {0}?",e[0]);case 2:return(0,o.kg)("contextkey.scanner.hint.didYouMean2","Did you mean {0} or {1}?",e[0],e[1]);case 3:return(0,o.kg)("contextkey.scanner.hint.didYouMean3","Did you mean {0}, {1} or {2}?",e[0],e[1],e[2]);default:return}}const l=(0,o.kg)("contextkey.scanner.hint.didYouForgetToOpenOrCloseQuote","Did you forget to open or close the quote?"),c=(0,o.kg)("contextkey.scanner.hint.didYouForgetToEscapeSlash","Did you forget to escape the '/' (slash) character? Put two backslashes before it to escape, e.g., '\\\\/'.");class h{constructor(){this._input="",this._start=0,this._current=0,this._tokens=[],this._errors=[],this.stringRe=/[a-zA-Z0-9_<>\-\./\\:\*\?\+\[\]\^,#@;"%\$\p{L}-]+/uy}static getLexeme(e){switch(e.type){case 0:return"(";case 1:return")";case 2:return"!";case 3:return e.isTripleEq?"===":"==";case 4:return e.isTripleEq?"!==":"!=";case 5:return"<";case 6:return"<=";case 7:case 8:return">=";case 9:return"=~";case 10:case 17:case 18:case 19:return e.lexeme;case 11:return"true";case 12:return"false";case 13:return"in";case 14:return"not";case 15:return"&&";case 16:return"||";case 20:return"EOF";default:throw(0,r.iH)(`unhandled token type: ${JSON.stringify(e)}; have you forgotten to add a case?`)}}static{this._regexFlags=new Set(["i","g","s","m","y","u"].map((e=>e.charCodeAt(0))))}static{this._keywords=new Map([["not",14],["in",13],["false",12],["true",11]])}reset(e){return this._input=e,this._start=0,this._current=0,this._tokens=[],this._errors=[],this}scan(){for(;!this._isAtEnd();){this._start=this._current;switch(this._advance()){case 40:this._addToken(0);break;case 41:this._addToken(1);break;case 33:if(this._match(61)){const e=this._match(61);this._tokens.push({type:4,offset:this._start,isTripleEq:e})}else this._addToken(2);break;case 39:this._quotedString();break;case 47:this._regex();break;case 61:if(this._match(61)){const e=this._match(61);this._tokens.push({type:3,offset:this._start,isTripleEq:e})}else this._match(126)?this._addToken(9):this._error(a("==","=~"));break;case 60:this._addToken(this._match(61)?6:5);break;case 62:this._addToken(this._match(61)?8:7);break;case 38:this._match(38)?this._addToken(15):this._error(a("&&"));break;case 124:this._match(124)?this._addToken(16):this._error(a("||"));break;case 32:case 13:case 9:case 10:case 160:break;default:this._string()}}return this._start=this._current,this._addToken(20),Array.from(this._tokens)}_match(e){return!this._isAtEnd()&&(this._input.charCodeAt(this._current)===e&&(this._current++,!0))}_advance(){return this._input.charCodeAt(this._current++)}_peek(){return this._isAtEnd()?0:this._input.charCodeAt(this._current)}_addToken(e){this._tokens.push({type:e,offset:this._start})}_error(e){const t=this._start,i=this._input.substring(this._start,this._current),s={type:19,offset:this._start,lexeme:i};this._errors.push({offset:t,lexeme:i,additionalInfo:e}),this._tokens.push(s)}_string(){this.stringRe.lastIndex=this._start;const e=this.stringRe.exec(this._input);if(e){this._current=this._start+e[0].length;const t=this._input.substring(this._start,this._current),i=h._keywords.get(t);i?this._addToken(i):this._tokens.push({type:17,lexeme:t,offset:this._start})}}_quotedString(){for(;39!==this._peek()&&!this._isAtEnd();)this._advance();this._isAtEnd()?this._error(l):(this._advance(),this._tokens.push({type:18,lexeme:this._input.substring(this._start+1,this._current-1),offset:this._start+1}))}_regex(){let e=this._current,t=!1,i=!1;for(;;){if(e>=this._input.length)return this._current=e,void this._error(c);const s=this._input.charCodeAt(e);if(t)t=!1;else{if(47===s&&!i){e++;break}91===s?i=!0:92===s?t=!0:93===s&&(i=!1)}e++}for(;e=this._input.length}}var d=i(63591);const u=new Map;u.set("false",!1),u.set("true",!0),u.set("isMac",s.zx),u.set("isLinux",s.j9),u.set("isWindows",s.uF),u.set("isWeb",s.HZ),u.set("isMacNative",s.zx&&!s.HZ),u.set("isEdge",s.UP),u.set("isFirefox",s.gm),u.set("isChrome",s.H8),u.set("isSafari",s.nr);const g=Object.prototype.hasOwnProperty,p={regexParsingWithErrorRecovery:!0},m=(0,o.kg)("contextkey.parser.error.emptyString","Empty context key expression"),f=(0,o.kg)("contextkey.parser.error.emptyString.hint","Did you forget to write an expression? You can also put 'false' or 'true' to always evaluate to false or true, respectively."),_=(0,o.kg)("contextkey.parser.error.noInAfterNot","'in' after 'not'."),v=(0,o.kg)("contextkey.parser.error.closingParenthesis","closing parenthesis ')'"),C=(0,o.kg)("contextkey.parser.error.unexpectedToken","Unexpected token"),b=(0,o.kg)("contextkey.parser.error.unexpectedToken.hint","Did you forget to put && or || before the token?"),E=(0,o.kg)("contextkey.parser.error.unexpectedEOF","Unexpected end of expression"),S=(0,o.kg)("contextkey.parser.error.unexpectedEOF.hint","Did you forget to put a context key?");class y{static{this._parseError=new Error}constructor(e=p){this._config=e,this._scanner=new h,this._tokens=[],this._current=0,this._parsingErrors=[],this._flagsGYRe=/g|y/g}parse(e){if(""!==e){this._tokens=this._scanner.reset(e).scan(),this._current=0,this._parsingErrors=[];try{const e=this._expr();if(!this._isAtEnd()){const e=this._peek(),t=17===e.type?b:void 0;throw this._parsingErrors.push({message:C,offset:e.offset,lexeme:h.getLexeme(e),additionalInfo:t}),y._parseError}return e}catch(t){if(t!==y._parseError)throw t;return}}else this._parsingErrors.push({message:m,offset:0,lexeme:"",additionalInfo:f})}_expr(){return this._or()}_or(){const e=[this._and()];for(;this._matchOne(16);){const t=this._and();e.push(t)}return 1===e.length?e[0]:w.or(...e)}_and(){const e=[this._term()];for(;this._matchOne(15);){const t=this._term();e.push(t)}return 1===e.length?e[0]:w.and(...e)}_term(){if(this._matchOne(2)){const e=this._peek();switch(e.type){case 11:return this._advance(),T.INSTANCE;case 12:return this._advance(),x.INSTANCE;case 0:{this._advance();const e=this._expr();return this._consume(1,v),e?.negate()}case 17:return this._advance(),D.create(e.lexeme);default:throw this._errExpectedButGot("KEY | true | false | '(' expression ')'",e)}}return this._primary()}_primary(){const e=this._peek();switch(e.type){case 11:return this._advance(),w.true();case 12:return this._advance(),w.false();case 0:{this._advance();const e=this._expr();return this._consume(1,v),e}case 17:{const s=e.lexeme;if(this._advance(),this._matchOne(9)){const e=this._peek();if(!this._config.regexParsingWithErrorRecovery){if(this._advance(),10!==e.type)throw this._errExpectedButGot("REGEX",e);const i=e.lexeme,n=i.lastIndexOf("/"),r=n===i.length-1?void 0:this._removeFlagsGY(i.substring(n+1));let o;try{o=new RegExp(i.substring(1,n),r)}catch(t){throw this._errExpectedButGot("REGEX",e)}return B.create(s,o)}switch(e.type){case 10:case 19:{const i=[e.lexeme];this._advance();let n=this._peek(),r=0;for(let t=0;t=0){const o=t.slice(s+1,n),a="i"===t[n+1]?"i":"";try{r=new RegExp(o,a)}catch(i){throw this._errExpectedButGot("REGEX",e)}}}if(null===r)throw this._errExpectedButGot("REGEX",e);return B.create(s,r)}default:throw this._errExpectedButGot("REGEX",this._peek())}}if(this._matchOne(14)){this._consume(13,_);const e=this._value();return w.notIn(s,e)}switch(this._peek().type){case 3:{this._advance();const e=this._value();if(18===this._previous().type)return w.equals(s,e);switch(e){case"true":return w.has(s);case"false":return w.not(s);default:return w.equals(s,e)}}case 4:{this._advance();const e=this._value();if(18===this._previous().type)return w.notEquals(s,e);switch(e){case"true":return w.not(s);case"false":return w.has(s);default:return w.notEquals(s,e)}}case 5:return this._advance(),U.create(s,this._value());case 6:return this._advance(),H.create(s,this._value());case 7:return this._advance(),P.create(s,this._value());case 8:return this._advance(),F.create(s,this._value());case 13:return this._advance(),w.in(s,this._value());default:return w.has(s)}}case 20:throw this._parsingErrors.push({message:E,offset:e.offset,lexeme:"",additionalInfo:S}),y._parseError;default:throw this._errExpectedButGot("true | false | KEY \n\t| KEY '=~' REGEX \n\t| KEY ('==' | '!=' | '<' | '<=' | '>' | '>=' | 'in' | 'not' 'in') value",this._peek())}}_value(){const e=this._peek();switch(e.type){case 17:case 18:return this._advance(),e.lexeme;case 11:return this._advance(),"true";case 12:return this._advance(),"false";case 13:return this._advance(),"in";default:return""}}_removeFlagsGY(e){return e.replaceAll(this._flagsGYRe,"")}_previous(){return this._tokens[this._current-1]}_matchOne(e){return!!this._check(e)&&(this._advance(),!0)}_advance(){return this._isAtEnd()||this._current++,this._previous()}_consume(e,t){if(this._check(e))return this._advance();throw this._errExpectedButGot(t,this._peek())}_errExpectedButGot(e,t,i){const s=(0,o.kg)("contextkey.parser.error.expectedButGot","Expected: {0}\nReceived: '{1}'.",e,h.getLexeme(t)),n=t.offset,r=h.getLexeme(t);return this._parsingErrors.push({message:s,offset:n,lexeme:r,additionalInfo:i}),y._parseError}_check(e){return this._peek().type===e}_peek(){return this._tokens[this._current]}_isAtEnd(){return 20===this._peek().type}}class w{static false(){return T.INSTANCE}static true(){return x.INSTANCE}static has(e){return k.create(e)}static equals(e,t){return A.create(e,t)}static notEquals(e,t){return O.create(e,t)}static regex(e,t){return B.create(e,t)}static in(e,t){return N.create(e,t)}static notIn(e,t){return I.create(e,t)}static not(e){return D.create(e)}static and(...e){return z.create(e,null,!0)}static or(...e){return G.create(e,null,!0)}static{this._parser=new y({regexParsingWithErrorRecovery:!1})}static deserialize(e){if(void 0===e||null===e)return;return this._parser.parse(e)}}function L(e,t){const i=e?e.substituteConstants():void 0,s=t?t.substituteConstants():void 0;return!i&&!s||!(!i||!s)&&i.equals(s)}function R(e,t){return e.cmp(t)}class T{static{this.INSTANCE=new T}constructor(){this.type=0}cmp(e){return this.type-e.type}equals(e){return e.type===this.type}substituteConstants(){return this}evaluate(e){return!1}serialize(){return"false"}keys(){return[]}negate(){return x.INSTANCE}}class x{static{this.INSTANCE=new x}constructor(){this.type=1}cmp(e){return this.type-e.type}equals(e){return e.type===this.type}substituteConstants(){return this}evaluate(e){return!0}serialize(){return"true"}keys(){return[]}negate(){return T.INSTANCE}}class k{static create(e,t=null){const i=u.get(e);return"boolean"===typeof i?i?x.INSTANCE:T.INSTANCE:new k(e,t)}constructor(e,t){this.key=e,this.negated=t,this.type=2}cmp(e){return e.type!==this.type?this.type-e.type:Y(this.key,e.key)}equals(e){return e.type===this.type&&this.key===e.key}substituteConstants(){const e=u.get(this.key);return"boolean"===typeof e?e?x.INSTANCE:T.INSTANCE:this}evaluate(e){return!!e.getValue(this.key)}serialize(){return this.key}keys(){return[this.key]}negate(){return this.negated||(this.negated=D.create(this.key,this)),this.negated}}class A{static create(e,t,i=null){if("boolean"===typeof t)return t?k.create(e,i):D.create(e,i);const s=u.get(e);if("boolean"===typeof s){return t===(s?"true":"false")?x.INSTANCE:T.INSTANCE}return new A(e,t,i)}constructor(e,t,i){this.key=e,this.value=t,this.negated=i,this.type=4}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){const e=u.get(this.key);if("boolean"===typeof e){const t=e?"true":"false";return this.value===t?x.INSTANCE:T.INSTANCE}return this}evaluate(e){return e.getValue(this.key)==this.value}serialize(){return`${this.key} == '${this.value}'`}keys(){return[this.key]}negate(){return this.negated||(this.negated=O.create(this.key,this.value,this)),this.negated}}class N{static create(e,t){return new N(e,t)}constructor(e,t){this.key=e,this.valueKey=t,this.type=10,this.negated=null}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.valueKey,e.key,e.valueKey)}equals(e){return e.type===this.type&&(this.key===e.key&&this.valueKey===e.valueKey)}substituteConstants(){return this}evaluate(e){const t=e.getValue(this.valueKey),i=e.getValue(this.key);return Array.isArray(t)?t.includes(i):"string"===typeof i&&"object"===typeof t&&null!==t&&g.call(t,i)}serialize(){return`${this.key} in '${this.valueKey}'`}keys(){return[this.key,this.valueKey]}negate(){return this.negated||(this.negated=I.create(this.key,this.valueKey)),this.negated}}class I{static create(e,t){return new I(e,t)}constructor(e,t){this.key=e,this.valueKey=t,this.type=11,this._negated=N.create(e,t)}cmp(e){return e.type!==this.type?this.type-e.type:this._negated.cmp(e._negated)}equals(e){return e.type===this.type&&this._negated.equals(e._negated)}substituteConstants(){return this}evaluate(e){return!this._negated.evaluate(e)}serialize(){return`${this.key} not in '${this.valueKey}'`}keys(){return this._negated.keys()}negate(){return this._negated}}class O{static create(e,t,i=null){if("boolean"===typeof t)return t?D.create(e,i):k.create(e,i);const s=u.get(e);if("boolean"===typeof s){return t===(s?"true":"false")?T.INSTANCE:x.INSTANCE}return new O(e,t,i)}constructor(e,t,i){this.key=e,this.value=t,this.negated=i,this.type=5}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){const e=u.get(this.key);if("boolean"===typeof e){const t=e?"true":"false";return this.value===t?T.INSTANCE:x.INSTANCE}return this}evaluate(e){return e.getValue(this.key)!=this.value}serialize(){return`${this.key} != '${this.value}'`}keys(){return[this.key]}negate(){return this.negated||(this.negated=A.create(this.key,this.value,this)),this.negated}}class D{static create(e,t=null){const i=u.get(e);return"boolean"===typeof i?i?T.INSTANCE:x.INSTANCE:new D(e,t)}constructor(e,t){this.key=e,this.negated=t,this.type=3}cmp(e){return e.type!==this.type?this.type-e.type:Y(this.key,e.key)}equals(e){return e.type===this.type&&this.key===e.key}substituteConstants(){const e=u.get(this.key);return"boolean"===typeof e?e?T.INSTANCE:x.INSTANCE:this}evaluate(e){return!e.getValue(this.key)}serialize(){return`!${this.key}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=k.create(this.key,this)),this.negated}}function M(e,t){if("string"===typeof e){const t=parseFloat(e);isNaN(t)||(e=t)}return"string"===typeof e||"number"===typeof e?t(e):T.INSTANCE}class P{static create(e,t,i=null){return M(t,(t=>new P(e,t,i)))}constructor(e,t,i){this.key=e,this.value=t,this.negated=i,this.type=12}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))>this.value}serialize(){return`${this.key} > ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=H.create(this.key,this.value,this)),this.negated}}class F{static create(e,t,i=null){return M(t,(t=>new F(e,t,i)))}constructor(e,t,i){this.key=e,this.value=t,this.negated=i,this.type=13}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))>=this.value}serialize(){return`${this.key} >= ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=U.create(this.key,this.value,this)),this.negated}}class U{static create(e,t,i=null){return M(t,(t=>new U(e,t,i)))}constructor(e,t,i){this.key=e,this.value=t,this.negated=i,this.type=14}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))new H(e,t,i)))}constructor(e,t,i){this.key=e,this.value=t,this.negated=i,this.type=15}cmp(e){return e.type!==this.type?this.type-e.type:q(this.key,this.value,e.key,e.value)}equals(e){return e.type===this.type&&(this.key===e.key&&this.value===e.value)}substituteConstants(){return this}evaluate(e){return"string"!==typeof this.value&&parseFloat(e.getValue(this.key))<=this.value}serialize(){return`${this.key} <= ${this.value}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=P.create(this.key,this.value,this)),this.negated}}class B{static create(e,t){return new B(e,t)}constructor(e,t){this.key=e,this.regexp=t,this.type=7,this.negated=null}cmp(e){if(e.type!==this.type)return this.type-e.type;if(this.keye.key)return 1;const t=this.regexp?this.regexp.source:"",i=e.regexp?e.regexp.source:"";return ti?1:0}equals(e){if(e.type===this.type){const t=this.regexp?this.regexp.source:"",i=e.regexp?e.regexp.source:"";return this.key===e.key&&t===i}return!1}substituteConstants(){return this}evaluate(e){const t=e.getValue(this.key);return!!this.regexp&&this.regexp.test(t)}serialize(){const e=this.regexp?`/${this.regexp.source}/${this.regexp.flags}`:"/invalid/";return`${this.key} =~ ${e}`}keys(){return[this.key]}negate(){return this.negated||(this.negated=W.create(this)),this.negated}}class W{static create(e){return new W(e)}constructor(e){this._actual=e,this.type=8}cmp(e){return e.type!==this.type?this.type-e.type:this._actual.cmp(e._actual)}equals(e){return e.type===this.type&&this._actual.equals(e._actual)}substituteConstants(){return this}evaluate(e){return!this._actual.evaluate(e)}serialize(){return`!(${this._actual.serialize()})`}keys(){return this._actual.keys()}negate(){return this._actual}}function V(e){let t=null;for(let i=0,s=e.length;ie.expr.length)return 1;for(let t=0,i=this.expr.length;t1;){const e=s[s.length-1];if(9!==e.type)break;s.pop();const t=s.pop(),n=0===s.length,r=G.create(e.expr.map((e=>z.create([e,t],null,i))),null,n);r&&(s.push(r),s.sort(R))}if(1===s.length)return s[0];if(i){for(let e=0;ee.serialize())).join(" && ")}keys(){const e=[];for(const t of this.expr)e.push(...t.keys());return e}negate(){if(!this.negated){const e=[];for(const t of this.expr)e.push(t.negate());this.negated=G.create(e,this,!0)}return this.negated}}class G{static create(e,t,i){return G._normalizeArr(e,t,i)}constructor(e,t){this.expr=e,this.negated=t,this.type=9}cmp(e){if(e.type!==this.type)return this.type-e.type;if(this.expr.lengthe.expr.length)return 1;for(let t=0,i=this.expr.length;te.serialize())).join(" || ")}keys(){const e=[];for(const t of this.expr)e.push(...t.keys());return e}negate(){if(!this.negated){const e=[];for(const t of this.expr)e.push(t.negate());for(;e.length>1;){const t=e.shift(),i=e.shift(),s=[];for(const e of X(t))for(const t of X(i))s.push(z.create([e,t],null,!1));e.unshift(G.create(s,null,!1))}this.negated=G.create(e,this,!0)}return this.negated}}class j extends k{static{this._info=[]}static all(){return j._info.values()}constructor(e,t,i){super(e,null),this._defaultValue=t,"object"===typeof i?j._info.push({...i,key:e}):!0!==i&&j._info.push({key:e,description:i,type:null!==t&&void 0!==t?typeof t:void 0})}bindTo(e){return e.createKey(this.key,this._defaultValue)}getValue(e){return e.getContextKeyValue(this.key)}toNegated(){return this.negate()}isEqualTo(e){return A.create(this.key,e)}}const K=(0,d.u1)("contextKeyService");function Y(e,t){return et?1:0}function q(e,t,i,s){return ei?1:ts?1:0}function $(e,t){if(0===e.type||1===t.type)return!0;if(9===e.type)return 9===t.type&&Q(e.expr,t.expr);if(9===t.type){for(const i of t.expr)if($(e,i))return!0;return!1}if(6===e.type){if(6===t.type)return Q(t.expr,e.expr);for(const i of e.expr)if($(i,t))return!0;return!1}return e.equals(t)}function Q(e,t){let i=0,s=0;for(;i{"use strict";i.d(t,{J7:()=>c,W0:()=>a,aV:()=>l,nd:()=>o});var s=i(98067),n=i(78209),r=i(32848);new r.N1("isMac",s.zx,(0,n.kg)("isMac","Whether the operating system is macOS")),new r.N1("isLinux",s.j9,(0,n.kg)("isLinux","Whether the operating system is Linux"));const o=new r.N1("isWindows",s.uF,(0,n.kg)("isWindows","Whether the operating system is Windows")),a=new r.N1("isWeb",s.HZ,(0,n.kg)("isWeb","Whether the platform is a web browser")),l=(new r.N1("isMacNative",s.zx&&!s.HZ,(0,n.kg)("isMacNative","Whether the operating system is macOS on a non-browser platform")),new r.N1("isIOS",s.un,(0,n.kg)("isIOS","Whether the operating system is iOS")),new r.N1("isMobile",s.Fr,(0,n.kg)("isMobile","Whether the platform is a mobile web browser")),new r.N1("isDevelopment",!1,!0),new r.N1("productQualityType","",(0,n.kg)("productQualityType","Quality type of VS Code")),"inputFocus"),c=new r.N1(l,!1,(0,n.kg)("inputFocus","Whether keyboard focus is inside an input box"))},47508:(e,t,i)=>{"use strict";i.d(t,{Z:()=>r,l:()=>n});var s=i(63591);const n=(0,s.u1)("contextViewService"),r=(0,s.u1)("contextMenuService")},59599:(e,t,i)=>{"use strict";i.d(t,{X:()=>s});const s=(0,i(63591).u1)("dialogService")},61292:(e,t,i)=>{"use strict";i.d(t,{PD:()=>r,sV:()=>n});var s=i(46359);const n={EDITORS:"CodeEditors",FILES:"CodeFiles"};s.O.add("workbench.contributions.dragAndDrop",new class{});class r{static{this.INSTANCE=new r}constructor(){}static getInstance(){return r.INSTANCE}hasData(e){return e&&e===this.proto}getData(e){if(this.hasData(e))return this.data}}},97035:(e,t,i)=>{"use strict";i.d(t,{k:()=>s});const s=(0,i(63591).u1)("environmentService")},7291:(e,t,i)=>{"use strict";var s;i.d(t,{p:()=>s}),function(e){e[e.FILE=0]="FILE",e[e.FOLDER=1]="FOLDER",e[e.ROOT_FOLDER=2]="ROOT_FOLDER"}(s||(s={}))},89100:(e,t,i)=>{"use strict";i.d(t,{pG:()=>x,_Q:()=>k,dg:()=>E});var s=i(88443),n=i(8597),r=i(35315),o=i(91581),a=i(17390),l=i(10350),c=i(41234),h=(i(10713),i(78209)),d=i(42904);const u=h.kg("defaultLabel","input"),g=h.kg("label.preserveCaseToggle","Preserve Case");class p extends r.l{constructor(e){super({icon:l.W.preserveCase,title:g+e.appendTitle,isChecked:e.isChecked,hoverDelegate:e.hoverDelegate??(0,d.nZ)("element"),inputActiveOptionBorder:e.inputActiveOptionBorder,inputActiveOptionForeground:e.inputActiveOptionForeground,inputActiveOptionBackground:e.inputActiveOptionBackground})}}class m extends a.x{constructor(e,t,i,s){super(),this._showOptionButtons=i,this.fixFocusOnOptionClickEnabled=!0,this.cachedOptionsWidth=0,this._onDidOptionChange=this._register(new c.vl),this.onDidOptionChange=this._onDidOptionChange.event,this._onKeyDown=this._register(new c.vl),this.onKeyDown=this._onKeyDown.event,this._onMouseDown=this._register(new c.vl),this._onInput=this._register(new c.vl),this._onKeyUp=this._register(new c.vl),this._onPreserveCaseKeyDown=this._register(new c.vl),this.onPreserveCaseKeyDown=this._onPreserveCaseKeyDown.event,this.contextViewProvider=t,this.placeholder=s.placeholder||"",this.validation=s.validation,this.label=s.label||u;const r=s.appendPreserveCaseLabel||"",a=s.history||[],l=!!s.flexibleHeight,h=!!s.flexibleWidth,d=s.flexibleMaxHeight;this.domNode=document.createElement("div"),this.domNode.classList.add("monaco-findInput"),this.inputBox=this._register(new o.mJ(this.domNode,this.contextViewProvider,{ariaLabel:this.label||"",placeholder:this.placeholder||"",validationOptions:{validation:this.validation},history:a,showHistoryHint:s.showHistoryHint,flexibleHeight:l,flexibleWidth:h,flexibleMaxHeight:d,inputBoxStyles:s.inputBoxStyles})),this.preserveCase=this._register(new p({appendTitle:r,isChecked:!1,...s.toggleStyles})),this._register(this.preserveCase.onChange((e=>{this._onDidOptionChange.fire(e),!e&&this.fixFocusOnOptionClickEnabled&&this.inputBox.focus(),this.validate()}))),this._register(this.preserveCase.onKeyDown((e=>{this._onPreserveCaseKeyDown.fire(e)}))),this._showOptionButtons?this.cachedOptionsWidth=this.preserveCase.width():this.cachedOptionsWidth=0;const g=[this.preserveCase.domNode];this.onkeydown(this.domNode,(e=>{if(e.equals(15)||e.equals(17)||e.equals(9)){const t=g.indexOf(this.domNode.ownerDocument.activeElement);if(t>=0){let i=-1;e.equals(17)?i=(t+1)%g.length:e.equals(15)&&(i=0===t?g.length-1:t-1),e.equals(9)?(g[t].blur(),this.inputBox.focus()):i>=0&&g[i].focus(),n.fs.stop(e,!0)}}}));const m=document.createElement("div");m.className="controls",m.style.display=this._showOptionButtons?"block":"none",m.appendChild(this.preserveCase.domNode),this.domNode.appendChild(m),e?.appendChild(this.domNode),this.onkeydown(this.inputBox.inputElement,(e=>this._onKeyDown.fire(e))),this.onkeyup(this.inputBox.inputElement,(e=>this._onKeyUp.fire(e))),this.oninput(this.inputBox.inputElement,(e=>this._onInput.fire())),this.onmousedown(this.inputBox.inputElement,(e=>this._onMouseDown.fire(e)))}enable(){this.domNode.classList.remove("disabled"),this.inputBox.enable(),this.preserveCase.enable()}disable(){this.domNode.classList.add("disabled"),this.inputBox.disable(),this.preserveCase.disable()}setEnabled(e){e?this.enable():this.disable()}select(){this.inputBox.select()}focus(){this.inputBox.focus()}getPreserveCase(){return this.preserveCase.checked}setPreserveCase(e){this.preserveCase.checked=e}focusOnPreserve(){this.preserveCase.focus()}validate(){this.inputBox?.validate()}set width(e){this.inputBox.paddingRight=this.cachedOptionsWidth,this.domNode.style.width=e+"px"}dispose(){super.dispose()}}var f=i(32848),_=i(59261),v=i(5662),C=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},b=function(e,t){return function(i,s){t(i,s,e)}};const E=new f.N1("suggestWidgetVisible",!1,(0,h.kg)("suggestWidgetVisible","Whether suggestion are visible")),S="historyNavigationWidgetFocus",y="historyNavigationForwardsEnabled",w="historyNavigationBackwardsEnabled";let L;const R=[];function T(e,t){if(R.includes(t))throw new Error("Cannot register the same widget multiple times");R.push(t);const i=new v.Cm,s=new f.N1(S,!1).bindTo(e),r=new f.N1(y,!0).bindTo(e),o=new f.N1(w,!0).bindTo(e),a=()=>{s.set(!0),L=t},l=()=>{s.set(!1),L===t&&(L=void 0)};return(0,n.X7)(t.element)&&a(),i.add(t.onDidFocus((()=>a()))),i.add(t.onDidBlur((()=>l()))),i.add((0,v.s)((()=>{R.splice(R.indexOf(t),1),l()}))),{historyNavigationForwardsEnablement:r,historyNavigationBackwardsEnablement:o,dispose(){i.dispose()}}}let x=class extends s.c{constructor(e,t,i,s){super(e,t,i);const n=this._register(s.createScoped(this.inputBox.element));this._register(T(n,this.inputBox))}};x=C([b(3,f.fN)],x);let k=class extends m{constructor(e,t,i,s,n=!1){super(e,t,n,i);const r=this._register(s.createScoped(this.inputBox.element));this._register(T(r,this.inputBox))}};k=C([b(3,f.fN)],k),_.f.registerCommandAndKeybindingRule({id:"history.showPrevious",weight:200,when:f.M$.and(f.M$.has(S),f.M$.equals(w,!0),f.M$.not("isComposing"),E.isEqualTo(!1)),primary:16,secondary:[528],handler:e=>{L?.showPreviousValue()}}),_.f.registerCommandAndKeybindingRule({id:"history.showNext",weight:200,when:f.M$.and(f.M$.has(S),f.M$.equals(y,!0),f.M$.not("isComposing"),E.isEqualTo(!1)),primary:18,secondary:[530],handler:e=>{L?.showNextValue()}})},67220:(e,t,i)=>{"use strict";i.d(t,{TN:()=>c,fO:()=>h});var s=i(63591),n=i(5662),r=i(84001),o=i(8597),a=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},l=function(e,t){return function(i,s){t(i,s,e)}};const c=(0,s.u1)("hoverService");let h=class extends n.jG{get delay(){return this.isInstantlyHovering()?0:this._delay}constructor(e,t,i={},s,r){super(),this.placement=e,this.instantHover=t,this.overrideOptions=i,this.configurationService=s,this.hoverService=r,this.lastHoverHideTime=0,this.timeLimit=200,this.hoverDisposables=this._register(new n.Cm),this._delay=this.configurationService.getValue("workbench.hover.delay"),this._register(this.configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration("workbench.hover.delay")&&(this._delay=this.configurationService.getValue("workbench.hover.delay"))})))}showHover(e,t){const i="function"===typeof this.overrideOptions?this.overrideOptions(e,t):this.overrideOptions;this.hoverDisposables.clear();const s=(0,o.sb)(e.target)?[e.target]:e.target.targetElements;for(const r of s)this.hoverDisposables.add((0,o.b2)(r,"keydown",(e=>{e.equals(9)&&this.hoverService.hideHover()})));const n=(0,o.sb)(e.content)?void 0:e.content.toString();return this.hoverService.showHover({...e,...i,persistence:{hideOnKeyDown:!0,...i.persistence},id:n,appearance:{...e.appearance,compact:!0,skipFadeInAnimation:this.isInstantlyHovering(),...i.appearance}},t)}isInstantlyHovering(){return this.instantHover&&Date.now()-this.lastHoverHideTime{"use strict";i.d(t,{d:()=>s});class s{constructor(e,t=[],i=!1){this.ctor=e,this.staticArguments=t,this.supportsDelayedInstantiation=i}}},14718:(e,t,i)=>{"use strict";i.d(t,{N:()=>o,v:()=>r});var s=i(84040);const n=[];function r(e,t,i){t instanceof s.d||(t=new s.d(t,[],Boolean(i))),n.push([e,t])}function o(){return n}},63591:(e,t,i)=>{"use strict";var s;i.d(t,{_$:()=>s,_Y:()=>n,u1:()=>r}),function(e){e.serviceIds=new Map,e.DI_TARGET="$di$target",e.DI_DEPENDENCIES="$di$dependencies",e.getServiceDependencies=function(t){return t[e.DI_DEPENDENCIES]||[]}}(s||(s={}));const n=r("instantiationService");function r(e){if(s.serviceIds.has(e))return s.serviceIds.get(e);const t=function(e,i,n){if(3!==arguments.length)throw new Error("@IServiceName-decorator can only be used to decorate a parameter");!function(e,t,i){t[s.DI_TARGET]===t?t[s.DI_DEPENDENCIES].push({id:e,index:i}):(t[s.DI_DEPENDENCIES]=[{id:e,index:i}],t[s.DI_TARGET]=t)}(t,e,n)};return t.toString=()=>e,s.serviceIds.set(e,t),t}},58345:(e,t,i)=>{"use strict";i.d(t,{a:()=>s});class s{constructor(...e){this._entries=new Map;for(const[t,i]of e)this.set(t,i)}set(e,t){const i=this._entries.get(e);return this._entries.set(e,t),i}get(e){return this._entries.get(e)}}},78748:(e,t,i)=>{"use strict";i.d(t,{F:()=>r});var s=i(41234),n=i(46359);const r={JSONContribution:"base.contributions.json"};const o=new class{constructor(){this._onDidChangeSchema=new s.vl,this.schemasById={}}registerSchema(e,t){var i;this.schemasById[(i=e,i.length>0&&"#"===i.charAt(i.length-1)?i.substring(0,i.length-1):i)]=t,this._onDidChangeSchema.fire(e)}notifySchemaChanged(e){this._onDidChangeSchema.fire(e)}};n.O.add(r.JSONContribution,o)},98031:(e,t,i)=>{"use strict";i.d(t,{b:()=>s});const s=(0,i(63591).u1)("keybindingService")},59261:(e,t,i)=>{"use strict";i.d(t,{f:()=>h});var s=i(42539),n=i(98067),r=i(50091),o=i(46359),a=i(5662),l=i(58925);class c{constructor(){this._coreKeybindings=new l.w,this._extensionKeybindings=[],this._cachedMergedKeybindings=null}static bindToCurrentPlatform(e){if(1===n.OS){if(e&&e.win)return e.win}else if(2===n.OS){if(e&&e.mac)return e.mac}else if(e&&e.linux)return e.linux;return e}registerKeybindingRule(e){const t=c.bindToCurrentPlatform(e),i=new a.Cm;if(t&&t.primary){const r=(0,s.Zv)(t.primary,n.OS);r&&i.add(this._registerDefaultKeybinding(r,e.id,e.args,e.weight,0,e.when))}if(t&&Array.isArray(t.secondary))for(let r=0,o=t.secondary.length;r{o(),this._cachedMergedKeybindings=null}))}getDefaultKeybindings(){return this._cachedMergedKeybindings||(this._cachedMergedKeybindings=Array.from(this._coreKeybindings).concat(this._extensionKeybindings),this._cachedMergedKeybindings.sort(d)),this._cachedMergedKeybindings.slice(0)}}const h=new c;function d(e,t){if(e.weight1!==t.weight1)return e.weight1-t.weight1;if(e.command&&t.command){if(e.commandt.command)return 1}return e.weight2-t.weight2}o.O.add("platform.keybindingsRegistry",h)},67841:(e,t,i)=>{"use strict";i.d(t,{L:()=>s});const s=(0,i(63591).u1)("labelService")},36584:(e,t,i)=>{"use strict";i.d(t,{PE:()=>Ce,aG:()=>be,er:()=>ft,YD:()=>Le,zL:()=>gt,Nf:()=>Ne,cH:()=>Oe});var s=i(8597),n=i(25890),r=i(18447),o=i(41234),a=i(5662),l=(i(48215),i(93090));class c{get templateId(){return this.renderer.templateId}constructor(e,t){this.renderer=e,this.modelProvider=t}renderTemplate(e){return{data:this.renderer.renderTemplate(e),disposable:a.jG.None}}renderElement(e,t,i,s){if(i.disposable?.dispose(),!i.data)return;const n=this.modelProvider();if(n.isResolved(e))return this.renderer.renderElement(n.get(e),e,i.data,s);const o=new r.Qi,a=n.resolve(e,o.token);i.disposable={dispose:()=>o.cancel()},this.renderer.renderPlaceholder(e,i.data),a.then((t=>this.renderer.renderElement(t,e,i.data,s)))}disposeTemplate(e){e.disposable&&(e.disposable.dispose(),e.disposable=void 0),e.data&&(this.renderer.disposeTemplate(e.data),e.data=void 0)}}class h{constructor(e,t){this.modelProvider=e,this.accessibilityProvider=t}getWidgetAriaLabel(){return this.accessibilityProvider.getWidgetAriaLabel()}getAriaLabel(e){const t=this.modelProvider();return t.isResolved(e)?this.accessibilityProvider.getAriaLabel(t.get(e)):null}}class d{constructor(e,t,i,s,n={}){const r=()=>this.model,o=s.map((e=>new c(e,r)));this.list=new l.B8(e,t,i,o,function(e,t){return{...t,accessibilityProvider:t.accessibilityProvider&&new h(e,t.accessibilityProvider)}}(r,n))}updateOptions(e){this.list.updateOptions(e)}getHTMLElement(){return this.list.getHTMLElement()}get onDidFocus(){return this.list.onDidFocus}get widget(){return this.list}get onDidDispose(){return this.list.onDidDispose}get onMouseDblClick(){return o.Jh.map(this.list.onMouseDblClick,(({element:e,index:t,browserEvent:i})=>({element:void 0===e?void 0:this._model.get(e),index:t,browserEvent:i})))}get onPointer(){return o.Jh.map(this.list.onPointer,(({element:e,index:t,browserEvent:i})=>({element:void 0===e?void 0:this._model.get(e),index:t,browserEvent:i})))}get onDidChangeSelection(){return o.Jh.map(this.list.onDidChangeSelection,(({elements:e,indexes:t,browserEvent:i})=>({elements:e.map((e=>this._model.get(e))),indexes:t,browserEvent:i})))}get model(){return this._model}set model(e){this._model=e,this.list.splice(0,this.list.length,(0,n.y1)(e.length))}getFocus(){return this.list.getFocus()}getSelection(){return this.list.getSelection()}getSelectedElements(){return this.getSelection().map((e=>this.model.get(e)))}style(e){this.list.style(e)}dispose(){this.list.dispose()}}var u=i(48196),g=i(42904),p=i(35151);class m{static{this.TemplateId="row"}constructor(e,t,i){this.columns=e,this.getColumnSize=i,this.templateId=m.TemplateId,this.renderedTemplates=new Set;const s=new Map(t.map((e=>[e.templateId,e])));this.renderers=[];for(const n of e){const e=s.get(n.templateId);if(!e)throw new Error(`Table cell renderer for template id ${n.templateId} not found.`);this.renderers.push(e)}}renderTemplate(e){const t=(0,s.BC)(e,(0,s.$)(".monaco-table-tr")),i=[],n=[];for(let o=0;othis.disposables.add(new f(e,t)))),d={size:h.reduce(((e,t)=>e+t.column.weight),0),views:h.map((e=>({size:e.column.weight,view:e})))};this.splitview=this.disposables.add(new p.U(this.domNode,{orientation:1,scrollbarVisibility:2,getSashOrthogonalSize:()=>this.cachedHeight,descriptor:d})),this.splitview.el.style.height=`${i.headerRowHeight}px`,this.splitview.el.style.lineHeight=`${i.headerRowHeight}px`;const u=new m(n,r,(e=>this.splitview.getViewSize(e)));var g;this.list=this.disposables.add(new l.B8(e,this.domNode,(g=i,{getHeight:e=>g.getHeight(e),getTemplateId:()=>m.TemplateId}),[u],c)),o.Jh.any(...h.map((e=>e.onDidLayout)))((([e,t])=>u.layoutColumn(e,t)),null,this.disposables),this.splitview.onDidSashReset((e=>{const t=n.reduce(((e,t)=>e+t.weight),0),i=n[e].weight/t*this.cachedWidth;this.splitview.resizeView(e,i)}),null,this.disposables),this.styleElement=(0,s.li)(this.domNode),this.style(l.bG)}updateOptions(e){this.list.updateOptions(e)}splice(e,t,i=[]){this.list.splice(e,t,i)}getHTMLElement(){return this.domNode}style(e){const t=[];t.push(`.monaco-table.${this.domId} > .monaco-split-view2 .monaco-sash.vertical::before {\n\t\t\ttop: ${this.virtualDelegate.headerRowHeight+1}px;\n\t\t\theight: calc(100% - ${this.virtualDelegate.headerRowHeight}px);\n\t\t}`),this.styleElement.textContent=t.join("\n"),this.list.style(e)}getSelectedElements(){return this.list.getSelectedElements()}getSelection(){return this.list.getSelection()}getFocus(){return this.list.getFocus()}dispose(){this.disposables.dispose()}}var v=i(19466),C=i(66700),b=i(37472),E=i(84565),S=i(42522);class y{constructor(e,t,i={}){this.user=e,this.rootRef=null,this.nodes=new Map,this.nodesByIdentity=new Map,this.model=new b.G6(e,t,null,i),this.onDidSplice=this.model.onDidSplice,this.onDidChangeCollapseState=this.model.onDidChangeCollapseState,this.onDidChangeRenderNodeCount=this.model.onDidChangeRenderNodeCount,i.sorter&&(this.sorter={compare:(e,t)=>i.sorter.compare(e.element,t.element)}),this.identityProvider=i.identityProvider}setChildren(e,t=S.f.empty(),i={}){const s=this.getElementLocation(e);this._setChildren(s,this.preserveCollapseState(t),i)}_setChildren(e,t=S.f.empty(),i){const s=new Set,n=new Set;this.model.splice([...e,0],Number.MAX_VALUE,t,{...i,onDidCreateNode:e=>{if(null===e.element)return;const t=e;if(s.add(t.element),this.nodes.set(t.element,t),this.identityProvider){const e=this.identityProvider.getId(t.element).toString();n.add(e),this.nodesByIdentity.set(e,t)}i.onDidCreateNode?.(t)},onDidDeleteNode:e=>{if(null===e.element)return;const t=e;if(s.has(t.element)||this.nodes.delete(t.element),this.identityProvider){const e=this.identityProvider.getId(t.element).toString();n.has(e)||this.nodesByIdentity.delete(e)}i.onDidDeleteNode?.(t)}})}preserveCollapseState(e=S.f.empty()){return this.sorter&&(e=[...e].sort(this.sorter.compare.bind(this.sorter))),S.f.map(e,(e=>{let t=this.nodes.get(e.element);if(!t&&this.identityProvider){const i=this.identityProvider.getId(e.element).toString();t=this.nodesByIdentity.get(i)}if(!t){let t;return t="undefined"===typeof e.collapsed?void 0:e.collapsed===E.Yo.Collapsed||e.collapsed===E.Yo.PreserveOrCollapsed||e.collapsed!==E.Yo.Expanded&&e.collapsed!==E.Yo.PreserveOrExpanded&&Boolean(e.collapsed),{...e,children:this.preserveCollapseState(e.children),collapsed:t}}const i="boolean"===typeof e.collapsible?e.collapsible:t.collapsible;let s;return s="undefined"===typeof e.collapsed||e.collapsed===E.Yo.PreserveOrCollapsed||e.collapsed===E.Yo.PreserveOrExpanded?t.collapsed:e.collapsed===E.Yo.Collapsed||e.collapsed!==E.Yo.Expanded&&Boolean(e.collapsed),{...e,collapsible:i,collapsed:s,children:this.preserveCollapseState(e.children)}}))}rerender(e){const t=this.getElementLocation(e);this.model.rerender(t)}getFirstElementChild(e=null){const t=this.getElementLocation(e);return this.model.getFirstElementChild(t)}has(e){return this.nodes.has(e)}getListIndex(e){const t=this.getElementLocation(e);return this.model.getListIndex(t)}getListRenderCount(e){const t=this.getElementLocation(e);return this.model.getListRenderCount(t)}isCollapsible(e){const t=this.getElementLocation(e);return this.model.isCollapsible(t)}setCollapsible(e,t){const i=this.getElementLocation(e);return this.model.setCollapsible(i,t)}isCollapsed(e){const t=this.getElementLocation(e);return this.model.isCollapsed(t)}setCollapsed(e,t,i){const s=this.getElementLocation(e);return this.model.setCollapsed(s,t,i)}expandTo(e){const t=this.getElementLocation(e);this.model.expandTo(t)}refilter(){this.model.refilter()}getNode(e=null){if(null===e)return this.model.getNode(this.model.rootRef);const t=this.nodes.get(e);if(!t)throw new E.jh(this.user,`Tree element not found: ${e}`);return t}getNodeLocation(e){return e.element}getParentNodeLocation(e){if(null===e)throw new E.jh(this.user,"Invalid getParentNodeLocation call");const t=this.nodes.get(e);if(!t)throw new E.jh(this.user,`Tree element not found: ${e}`);const i=this.model.getNodeLocation(t),s=this.model.getParentNodeLocation(i);return this.model.getNode(s).element}getElementLocation(e){if(null===e)return[];const t=this.nodes.get(e);if(!t)throw new E.jh(this.user,`Tree element not found: ${e}`);return this.model.getNodeLocation(t)}}function w(e){return{element:{elements:[e.element],incompressible:e.incompressible||!1},children:S.f.map(S.f.from(e.children),w),collapsible:e.collapsible,collapsed:e.collapsed}}function L(e){const t=[e.element],i=e.incompressible||!1;let s,n;for(;[n,s]=S.f.consume(S.f.from(e.children),2),1===n.length&&!n[0].incompressible;)e=n[0],t.push(e.element);return{element:{elements:t,incompressible:i},children:S.f.map(S.f.concat(n,s),L),collapsible:e.collapsible,collapsed:e.collapsed}}function R(e,t=0){let i;return i=tR(e,0))),0===t&&e.element.incompressible?{element:e.element.elements[t],children:i,incompressible:!0,collapsible:e.collapsible,collapsed:e.collapsed}:{element:e.element.elements[t],children:i,collapsible:e.collapsible,collapsed:e.collapsed}}function T(e){return R(e,0)}function x(e,t,i){return e.element===t?{...e,children:i}:{...e,children:S.f.map(S.f.from(e.children),(e=>x(e,t,i)))}}class k{get onDidSplice(){return this.model.onDidSplice}get onDidChangeCollapseState(){return this.model.onDidChangeCollapseState}get onDidChangeRenderNodeCount(){return this.model.onDidChangeRenderNodeCount}constructor(e,t,i={}){this.user=e,this.rootRef=null,this.nodes=new Map,this.model=new y(e,t,i),this.enabled="undefined"===typeof i.compressionEnabled||i.compressionEnabled,this.identityProvider=i.identityProvider}setChildren(e,t=S.f.empty(),i){const s=i.diffIdentityProvider&&(r=i.diffIdentityProvider,{getId:e=>e.elements.map((e=>r.getId(e).toString())).join("\0")});var r;if(null===e){const e=S.f.map(t,this.enabled?L:w);return void this._setChildren(null,e,{diffIdentityProvider:s,diffDepth:1/0})}const o=this.nodes.get(e);if(!o)throw new E.jh(this.user,"Unknown compressed tree node");const a=this.model.getNode(o),l=this.model.getParentNodeLocation(o),c=this.model.getNode(l),h=x(T(a),e,t),d=(this.enabled?L:w)(h),u=i.diffIdentityProvider?(e,t)=>i.diffIdentityProvider.getId(e)===i.diffIdentityProvider.getId(t):void 0;if((0,n.aI)(d.element.elements,a.element.elements,u))return void this._setChildren(o,d.children||S.f.empty(),{diffIdentityProvider:s,diffDepth:1});const g=c.children.map((e=>e===a?d:e));this._setChildren(c.element,g,{diffIdentityProvider:s,diffDepth:a.depth-c.depth})}isCompressionEnabled(){return this.enabled}setCompressionEnabled(e){if(e===this.enabled)return;this.enabled=e;const t=this.model.getNode().children,i=S.f.map(t,T),s=S.f.map(i,e?L:w);this._setChildren(null,s,{diffIdentityProvider:this.identityProvider,diffDepth:1/0})}_setChildren(e,t,i){const s=new Set;this.model.setChildren(e,t,{...i,onDidCreateNode:e=>{for(const t of e.element.elements)s.add(t),this.nodes.set(t,e.element)},onDidDeleteNode:e=>{for(const t of e.element.elements)s.has(t)||this.nodes.delete(t)}})}has(e){return this.nodes.has(e)}getListIndex(e){const t=this.getCompressedNode(e);return this.model.getListIndex(t)}getListRenderCount(e){const t=this.getCompressedNode(e);return this.model.getListRenderCount(t)}getNode(e){if("undefined"===typeof e)return this.model.getNode();const t=this.getCompressedNode(e);return this.model.getNode(t)}getNodeLocation(e){const t=this.model.getNodeLocation(e);return null===t?null:t.elements[t.elements.length-1]}getParentNodeLocation(e){const t=this.getCompressedNode(e),i=this.model.getParentNodeLocation(t);return null===i?null:i.elements[i.elements.length-1]}getFirstElementChild(e){const t=this.getCompressedNode(e);return this.model.getFirstElementChild(t)}isCollapsible(e){const t=this.getCompressedNode(e);return this.model.isCollapsible(t)}setCollapsible(e,t){const i=this.getCompressedNode(e);return this.model.setCollapsible(i,t)}isCollapsed(e){const t=this.getCompressedNode(e);return this.model.isCollapsed(t)}setCollapsed(e,t,i){const s=this.getCompressedNode(e);return this.model.setCollapsed(s,t,i)}expandTo(e){const t=this.getCompressedNode(e);this.model.expandTo(t)}rerender(e){const t=this.getCompressedNode(e);this.model.rerender(t)}refilter(){this.model.refilter()}getCompressedNode(e){if(null===e)return null;const t=this.nodes.get(e);if(!t)throw new E.jh(this.user,`Tree element not found: ${e}`);return t}}const A=e=>e[e.length-1];class N{get element(){return null===this.node.element?null:this.unwrapper(this.node.element)}get children(){return this.node.children.map((e=>new N(this.unwrapper,e)))}get depth(){return this.node.depth}get visibleChildrenCount(){return this.node.visibleChildrenCount}get visibleChildIndex(){return this.node.visibleChildIndex}get collapsible(){return this.node.collapsible}get collapsed(){return this.node.collapsed}get visible(){return this.node.visible}get filterData(){return this.node.filterData}constructor(e,t){this.unwrapper=e,this.node=t}}class I{get onDidSplice(){return o.Jh.map(this.model.onDidSplice,(({insertedNodes:e,deletedNodes:t})=>({insertedNodes:e.map((e=>this.nodeMapper.map(e))),deletedNodes:t.map((e=>this.nodeMapper.map(e)))})))}get onDidChangeCollapseState(){return o.Jh.map(this.model.onDidChangeCollapseState,(({node:e,deep:t})=>({node:this.nodeMapper.map(e),deep:t})))}get onDidChangeRenderNodeCount(){return o.Jh.map(this.model.onDidChangeRenderNodeCount,(e=>this.nodeMapper.map(e)))}constructor(e,t,i={}){this.rootRef=null,this.elementMapper=i.elementMapper||A;const s=e=>this.elementMapper(e.elements);this.nodeMapper=new E.y2((e=>new N(s,e))),this.model=new k(e,function(e,t){return{splice(i,s,n){t.splice(i,s,n.map((t=>e.map(t))))},updateElementHeight(e,i){t.updateElementHeight(e,i)}}}(this.nodeMapper,t),function(e,t){return{...t,identityProvider:t.identityProvider&&{getId:i=>t.identityProvider.getId(e(i))},sorter:t.sorter&&{compare:(e,i)=>t.sorter.compare(e.elements[0],i.elements[0])},filter:t.filter&&{filter:(i,s)=>t.filter.filter(e(i),s)}}}(s,i))}setChildren(e,t=S.f.empty(),i={}){this.model.setChildren(e,t,i)}isCompressionEnabled(){return this.model.isCompressionEnabled()}setCompressionEnabled(e){this.model.setCompressionEnabled(e)}has(e){return this.model.has(e)}getListIndex(e){return this.model.getListIndex(e)}getListRenderCount(e){return this.model.getListRenderCount(e)}getNode(e){return this.nodeMapper.map(this.model.getNode(e))}getNodeLocation(e){return e.element}getParentNodeLocation(e){return this.model.getParentNodeLocation(e)}getFirstElementChild(e){const t=this.model.getFirstElementChild(e);return null===t||"undefined"===typeof t?t:this.elementMapper(t.elements)}isCollapsible(e){return this.model.isCollapsible(e)}setCollapsible(e,t){return this.model.setCollapsible(e,t)}isCollapsed(e){return this.model.isCollapsed(e)}setCollapsed(e,t,i){return this.model.setCollapsed(e,t,i)}expandTo(e){return this.model.expandTo(e)}rerender(e){return this.model.rerender(e)}refilter(){return this.model.refilter()}getCompressedTreeNode(e=null){return this.model.getNode(e)}}var O=i(58694),D=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o};class M extends v.DO{get onDidChangeCollapseState(){return this.model.onDidChangeCollapseState}constructor(e,t,i,s,n={}){super(e,t,i,s,n),this.user=e}setChildren(e,t=S.f.empty(),i){this.model.setChildren(e,t,i)}rerender(e){void 0!==e?this.model.rerender(e):this.view.rerender()}hasElement(e){return this.model.has(e)}createModel(e,t,i){return new y(e,t,i)}}class P{get compressedTreeNodeProvider(){return this._compressedTreeNodeProvider()}constructor(e,t,i){this._compressedTreeNodeProvider=e,this.stickyScrollDelegate=t,this.renderer=i,this.templateId=i.templateId,i.onDidChangeTwistieState&&(this.onDidChangeTwistieState=i.onDidChangeTwistieState)}renderTemplate(e){return{compressedTreeNode:void 0,data:this.renderer.renderTemplate(e)}}renderElement(e,t,i,s){let n=this.stickyScrollDelegate.getCompressedNode(e);n||(n=this.compressedTreeNodeProvider.getCompressedTreeNode(e.element)),1===n.element.elements.length?(i.compressedTreeNode=void 0,this.renderer.renderElement(e,t,i.data,s)):(i.compressedTreeNode=n,this.renderer.renderCompressedElements(n,t,i.data,s))}disposeElement(e,t,i,s){i.compressedTreeNode?this.renderer.disposeCompressedElements?.(i.compressedTreeNode,t,i.data,s):this.renderer.disposeElement?.(e,t,i.data,s)}disposeTemplate(e){this.renderer.disposeTemplate(e.data)}renderTwistie(e,t){return!!this.renderer.renderTwistie&&this.renderer.renderTwistie(e,t)}}D([O.B],P.prototype,"compressedTreeNodeProvider",null);class F{constructor(e){this.modelProvider=e,this.compressedStickyNodes=new Map}getCompressedNode(e){return this.compressedStickyNodes.get(e)}constrainStickyScrollNodes(e,t,i){if(this.compressedStickyNodes.clear(),0===e.length)return[];for(let s=0;si||s>=t-1&&tthis,o=new F((()=>this.model));super(e,t,i,s.map((e=>new P(r,o,e))),{...U(r,n),stickyScrollDelegate:o})}setChildren(e,t=S.f.empty(),i){this.model.setChildren(e,t,i)}createModel(e,t,i){return new I(e,t,i)}updateOptions(e={}){super.updateOptions(e),"undefined"!==typeof e.compressionEnabled&&this.model.setCompressionEnabled(e.compressionEnabled)}getCompressedTreeNode(e=null){return this.model.getCompressedTreeNode(e)}}var B=i(90766),W=i(10350),V=i(25689),z=i(64383),G=i(631);function j(e){return{...e,children:[],refreshPromise:void 0,stale:!0,slow:!1,forceExpanded:!1}}function K(e,t){return!!t.parent&&(t.parent===e||K(e,t.parent))}class Y{get element(){return this.node.element.element}get children(){return this.node.children.map((e=>new Y(e)))}get depth(){return this.node.depth}get visibleChildrenCount(){return this.node.visibleChildrenCount}get visibleChildIndex(){return this.node.visibleChildIndex}get collapsible(){return this.node.collapsible}get collapsed(){return this.node.collapsed}get visible(){return this.node.visible}get filterData(){return this.node.filterData}constructor(e){this.node=e}}class q{constructor(e,t,i){this.renderer=e,this.nodeMapper=t,this.onDidChangeTwistieState=i,this.renderedNodes=new Map,this.templateId=e.templateId}renderTemplate(e){return{templateData:this.renderer.renderTemplate(e)}}renderElement(e,t,i,s){this.renderer.renderElement(this.nodeMapper.map(e),t,i.templateData,s)}renderTwistie(e,t){return e.slow?(t.classList.add(...V.L.asClassNameArray(W.W.treeItemLoading)),!0):(t.classList.remove(...V.L.asClassNameArray(W.W.treeItemLoading)),!1)}disposeElement(e,t,i,s){this.renderer.disposeElement?.(this.nodeMapper.map(e),t,i.templateData,s)}disposeTemplate(e){this.renderer.disposeTemplate(e.templateData)}dispose(){this.renderedNodes.clear()}}function $(e){return{browserEvent:e.browserEvent,elements:e.elements.map((e=>e.element))}}function Q(e){return{browserEvent:e.browserEvent,element:e.element&&e.element.element,target:e.target}}class X extends C.ur{constructor(e){super(e.elements.map((e=>e.element))),this.data=e}}function Z(e){return e instanceof C.ur?new X(e):e}class J{constructor(e){this.dnd=e}getDragURI(e){return this.dnd.getDragURI(e.element)}getDragLabel(e,t){if(this.dnd.getDragLabel)return this.dnd.getDragLabel(e.map((e=>e.element)),t)}onDragStart(e,t){this.dnd.onDragStart?.(Z(e),t)}onDragOver(e,t,i,s,n,r=!0){return this.dnd.onDragOver(Z(e),t&&t.element,i,s,n)}drop(e,t,i,s,n){this.dnd.drop(Z(e),t&&t.element,i,s,n)}onDragEnd(e){this.dnd.onDragEnd?.(e)}dispose(){this.dnd.dispose()}}function ee(e){return e&&{...e,collapseByDefault:!0,identityProvider:e.identityProvider&&{getId:t=>e.identityProvider.getId(t.element)},dnd:e.dnd&&new J(e.dnd),multipleSelectionController:e.multipleSelectionController&&{isSelectionSingleChangeEvent:t=>e.multipleSelectionController.isSelectionSingleChangeEvent({...t,element:t.element}),isSelectionRangeChangeEvent:t=>e.multipleSelectionController.isSelectionRangeChangeEvent({...t,element:t.element})},accessibilityProvider:e.accessibilityProvider&&{...e.accessibilityProvider,getPosInSet:void 0,getSetSize:void 0,getRole:e.accessibilityProvider.getRole?t=>e.accessibilityProvider.getRole(t.element):()=>"treeitem",isChecked:e.accessibilityProvider.isChecked?t=>!!e.accessibilityProvider?.isChecked(t.element):void 0,getAriaLabel:t=>e.accessibilityProvider.getAriaLabel(t.element),getWidgetAriaLabel:()=>e.accessibilityProvider.getWidgetAriaLabel(),getWidgetRole:e.accessibilityProvider.getWidgetRole?()=>e.accessibilityProvider.getWidgetRole():()=>"tree",getAriaLevel:e.accessibilityProvider.getAriaLevel&&(t=>e.accessibilityProvider.getAriaLevel(t.element)),getActiveDescendantId:e.accessibilityProvider.getActiveDescendantId&&(t=>e.accessibilityProvider.getActiveDescendantId(t.element))},filter:e.filter&&{filter:(t,i)=>e.filter.filter(t.element,i)},keyboardNavigationLabelProvider:e.keyboardNavigationLabelProvider&&{...e.keyboardNavigationLabelProvider,getKeyboardNavigationLabel:t=>e.keyboardNavigationLabelProvider.getKeyboardNavigationLabel(t.element)},sorter:void 0,expandOnlyOnTwistieClick:"undefined"===typeof e.expandOnlyOnTwistieClick?void 0:"function"!==typeof e.expandOnlyOnTwistieClick?e.expandOnlyOnTwistieClick:t=>e.expandOnlyOnTwistieClick(t.element),defaultFindVisibility:t=>t.hasChildren&&t.stale?1:"number"===typeof e.defaultFindVisibility?e.defaultFindVisibility:"undefined"===typeof e.defaultFindVisibility?2:e.defaultFindVisibility(t.element)}}function te(e,t){t(e),e.children.forEach((e=>te(e,t)))}class ie{get onDidScroll(){return this.tree.onDidScroll}get onDidChangeFocus(){return o.Jh.map(this.tree.onDidChangeFocus,$)}get onDidChangeSelection(){return o.Jh.map(this.tree.onDidChangeSelection,$)}get onMouseDblClick(){return o.Jh.map(this.tree.onMouseDblClick,Q)}get onPointer(){return o.Jh.map(this.tree.onPointer,Q)}get onDidFocus(){return this.tree.onDidFocus}get onDidChangeModel(){return this.tree.onDidChangeModel}get onDidChangeCollapseState(){return this.tree.onDidChangeCollapseState}get onDidChangeFindOpenState(){return this.tree.onDidChangeFindOpenState}get onDidChangeStickyScrollFocused(){return this.tree.onDidChangeStickyScrollFocused}get onDidDispose(){return this.tree.onDidDispose}constructor(e,t,i,s,n,r={}){this.user=e,this.dataSource=n,this.nodes=new Map,this.subTreeRefreshPromises=new Map,this.refreshPromises=new Map,this._onDidRender=new o.vl,this._onDidChangeNodeSlowState=new o.vl,this.nodeMapper=new E.y2((e=>new Y(e))),this.disposables=new a.Cm,this.identityProvider=r.identityProvider,this.autoExpandSingleChildren="undefined"!==typeof r.autoExpandSingleChildren&&r.autoExpandSingleChildren,this.sorter=r.sorter,this.getDefaultCollapseState=e=>r.collapseByDefault?r.collapseByDefault(e)?E.Yo.PreserveOrCollapsed:E.Yo.PreserveOrExpanded:void 0,this.tree=this.createTree(e,t,i,s,r),this.onDidChangeFindMode=this.tree.onDidChangeFindMode,this.onDidChangeFindMatchType=this.tree.onDidChangeFindMatchType,this.root=j({element:void 0,parent:null,hasChildren:!0,defaultCollapseState:void 0}),this.identityProvider&&(this.root={...this.root,id:null}),this.nodes.set(null,this.root),this.tree.onDidChangeCollapseState(this._onDidChangeCollapseState,this,this.disposables)}createTree(e,t,i,s,n){const r=new v.w0(i),o=s.map((e=>new q(e,this.nodeMapper,this._onDidChangeNodeSlowState.event))),a=ee(n)||{};return new M(e,t,r,o,a)}updateOptions(e={}){this.tree.updateOptions(e)}getHTMLElement(){return this.tree.getHTMLElement()}get scrollTop(){return this.tree.scrollTop}set scrollTop(e){this.tree.scrollTop=e}get scrollHeight(){return this.tree.scrollHeight}get renderHeight(){return this.tree.renderHeight}domFocus(){this.tree.domFocus()}layout(e,t){this.tree.layout(e,t)}style(e){this.tree.style(e)}getInput(){return this.root.element}async setInput(e,t){this.refreshPromises.forEach((e=>e.cancel())),this.refreshPromises.clear(),this.root.element=e;const i=t&&{viewState:t,focus:[],selection:[]};await this._updateChildren(e,!0,!1,i),i&&(this.tree.setFocus(i.focus),this.tree.setSelection(i.selection)),t&&"number"===typeof t.scrollTop&&(this.scrollTop=t.scrollTop)}async _updateChildren(e=this.root.element,t=!0,i=!1,s,n){if("undefined"===typeof this.root.element)throw new E.jh(this.user,"Tree input not set");this.root.refreshPromise&&(await this.root.refreshPromise,await o.Jh.toPromise(this._onDidRender.event));const r=this.getDataNode(e);if(await this.refreshAndRenderNode(r,t,s,n),i)try{this.tree.rerender(r)}catch{}}rerender(e){if(void 0===e||e===this.root.element)return void this.tree.rerender();const t=this.getDataNode(e);this.tree.rerender(t)}getNode(e=this.root.element){const t=this.getDataNode(e),i=this.tree.getNode(t===this.root?null:t);return this.nodeMapper.map(i)}collapse(e,t=!1){const i=this.getDataNode(e);return this.tree.collapse(i===this.root?null:i,t)}async expand(e,t=!1){if("undefined"===typeof this.root.element)throw new E.jh(this.user,"Tree input not set");this.root.refreshPromise&&(await this.root.refreshPromise,await o.Jh.toPromise(this._onDidRender.event));const i=this.getDataNode(e);if(this.tree.hasElement(i)&&!this.tree.isCollapsible(i))return!1;if(i.refreshPromise&&(await this.root.refreshPromise,await o.Jh.toPromise(this._onDidRender.event)),i!==this.root&&!i.refreshPromise&&!this.tree.isCollapsed(i))return!1;const s=this.tree.expand(i===this.root?null:i,t);return i.refreshPromise&&(await this.root.refreshPromise,await o.Jh.toPromise(this._onDidRender.event)),s}setSelection(e,t){const i=e.map((e=>this.getDataNode(e)));this.tree.setSelection(i,t)}getSelection(){return this.tree.getSelection().map((e=>e.element))}setFocus(e,t){const i=e.map((e=>this.getDataNode(e)));this.tree.setFocus(i,t)}getFocus(){return this.tree.getFocus().map((e=>e.element))}reveal(e,t){this.tree.reveal(this.getDataNode(e),t)}getParentElement(e){const t=this.tree.getParentElement(this.getDataNode(e));return t&&t.element}getFirstElementChild(e=this.root.element){const t=this.getDataNode(e),i=this.tree.getFirstElementChild(t===this.root?null:t);return i&&i.element}getDataNode(e){const t=this.nodes.get(e===this.root.element?null:e);if(!t)throw new E.jh(this.user,`Data tree node not found: ${e}`);return t}async refreshAndRenderNode(e,t,i,s){await this.refreshNode(e,t,i),this.disposables.isDisposed||this.render(e,i,s)}async refreshNode(e,t,i){let s;if(this.subTreeRefreshPromises.forEach(((n,r)=>{!s&&function(e,t){return e===t||K(e,t)||K(t,e)}(r,e)&&(s=n.then((()=>this.refreshNode(e,t,i))))})),s)return s;if(e!==this.root){if(this.tree.getNode(e).collapsed)return e.hasChildren=!!this.dataSource.hasChildren(e.element),e.stale=!0,void this.setChildren(e,[],t,i)}return this.doRefreshSubTree(e,t,i)}async doRefreshSubTree(e,t,i){let s;e.refreshPromise=new Promise((e=>s=e)),this.subTreeRefreshPromises.set(e,e.refreshPromise),e.refreshPromise.finally((()=>{e.refreshPromise=void 0,this.subTreeRefreshPromises.delete(e)}));try{const s=await this.doRefreshNode(e,t,i);e.stale=!1,await B.HC.settled(s.map((e=>this.doRefreshSubTree(e,t,i))))}finally{s()}}async doRefreshNode(e,t,i){let s;if(e.hasChildren=!!this.dataSource.hasChildren(e.element),e.hasChildren){const t=this.doGetChildren(e);if((0,G.xZ)(t))s=Promise.resolve(t);else{const i=(0,B.wR)(800);i.then((()=>{e.slow=!0,this._onDidChangeNodeSlowState.fire(e)}),(e=>null)),s=t.finally((()=>i.cancel()))}}else s=Promise.resolve(S.f.empty());try{const n=await s;return this.setChildren(e,n,t,i)}catch(n){if(e!==this.root&&this.tree.hasElement(e)&&this.tree.collapse(e),(0,z.MB)(n))return[];throw n}finally{e.slow&&(e.slow=!1,this._onDidChangeNodeSlowState.fire(e))}}doGetChildren(e){let t=this.refreshPromises.get(e);if(t)return t;const i=this.dataSource.getChildren(e.element);return(0,G.xZ)(i)?this.processChildren(i):(t=(0,B.SS)((async()=>this.processChildren(await i))),this.refreshPromises.set(e,t),t.finally((()=>{this.refreshPromises.delete(e)})))}_onDidChangeCollapseState({node:e,deep:t}){null!==e.element&&!e.collapsed&&e.element.stale&&(t?this.collapse(e.element.element):this.refreshAndRenderNode(e.element,!1).catch(z.dz))}setChildren(e,t,i,s){const n=[...t];if(0===e.children.length&&0===n.length)return[];const r=new Map,o=new Map;for(const c of e.children)r.set(c.element,c),this.identityProvider&&o.set(c.id,{node:c,collapsed:this.tree.hasElement(c)&&this.tree.isCollapsed(c)});const a=[],l=n.map((t=>{const n=!!this.dataSource.hasChildren(t);if(!this.identityProvider){const i=j({element:t,parent:e,hasChildren:n,defaultCollapseState:this.getDefaultCollapseState(t)});return n&&i.defaultCollapseState===E.Yo.PreserveOrExpanded&&a.push(i),i}const l=this.identityProvider.getId(t).toString(),c=o.get(l);if(c){const e=c.node;return r.delete(e.element),this.nodes.delete(e.element),this.nodes.set(t,e),e.element=t,e.hasChildren=n,i?c.collapsed?(e.children.forEach((e=>te(e,(e=>this.nodes.delete(e.element))))),e.children.splice(0,e.children.length),e.stale=!0):a.push(e):n&&!c.collapsed&&a.push(e),e}const h=j({element:t,parent:e,id:l,hasChildren:n,defaultCollapseState:this.getDefaultCollapseState(t)});return s&&s.viewState.focus&&s.viewState.focus.indexOf(l)>-1&&s.focus.push(h),s&&s.viewState.selection&&s.viewState.selection.indexOf(l)>-1&&s.selection.push(h),(s&&s.viewState.expanded&&s.viewState.expanded.indexOf(l)>-1||n&&h.defaultCollapseState===E.Yo.PreserveOrExpanded)&&a.push(h),h}));for(const c of r.values())te(c,(e=>this.nodes.delete(e.element)));for(const c of l)this.nodes.set(c.element,c);return e.children.splice(0,e.children.length,...l),e!==this.root&&this.autoExpandSingleChildren&&1===l.length&&0===a.length&&(l[0].forceExpanded=!0,a.push(l[0])),a}render(e,t,i){const s=e.children.map((e=>this.asTreeElement(e,t))),n=i&&{...i,diffIdentityProvider:i.diffIdentityProvider&&{getId:e=>i.diffIdentityProvider.getId(e.element)}};this.tree.setChildren(e===this.root?null:e,s,n),e!==this.root&&this.tree.setCollapsible(e,e.hasChildren),this._onDidRender.fire()}asTreeElement(e,t){if(e.stale)return{element:e,collapsible:e.hasChildren,collapsed:!0};let i;return t&&t.viewState.expanded&&e.id&&t.viewState.expanded.indexOf(e.id)>-1?i=!1:e.forceExpanded?(i=!1,e.forceExpanded=!1):i=e.defaultCollapseState,{element:e,children:e.hasChildren?S.f.map(e.children,(e=>this.asTreeElement(e,t))):[],collapsible:e.hasChildren,collapsed:i}}processChildren(e){return this.sorter&&(e=[...e].sort(this.sorter.compare.bind(this.sorter))),e}dispose(){this.disposables.dispose(),this.tree.dispose()}}class se{get element(){return{elements:this.node.element.elements.map((e=>e.element)),incompressible:this.node.element.incompressible}}get children(){return this.node.children.map((e=>new se(e)))}get depth(){return this.node.depth}get visibleChildrenCount(){return this.node.visibleChildrenCount}get visibleChildIndex(){return this.node.visibleChildIndex}get collapsible(){return this.node.collapsible}get collapsed(){return this.node.collapsed}get visible(){return this.node.visible}get filterData(){return this.node.filterData}constructor(e){this.node=e}}class ne{constructor(e,t,i,s){this.renderer=e,this.nodeMapper=t,this.compressibleNodeMapperProvider=i,this.onDidChangeTwistieState=s,this.renderedNodes=new Map,this.disposables=[],this.templateId=e.templateId}renderTemplate(e){return{templateData:this.renderer.renderTemplate(e)}}renderElement(e,t,i,s){this.renderer.renderElement(this.nodeMapper.map(e),t,i.templateData,s)}renderCompressedElements(e,t,i,s){this.renderer.renderCompressedElements(this.compressibleNodeMapperProvider().map(e),t,i.templateData,s)}renderTwistie(e,t){return e.slow?(t.classList.add(...V.L.asClassNameArray(W.W.treeItemLoading)),!0):(t.classList.remove(...V.L.asClassNameArray(W.W.treeItemLoading)),!1)}disposeElement(e,t,i,s){this.renderer.disposeElement?.(this.nodeMapper.map(e),t,i.templateData,s)}disposeCompressedElements(e,t,i,s){this.renderer.disposeCompressedElements?.(this.compressibleNodeMapperProvider().map(e),t,i.templateData,s)}disposeTemplate(e){this.renderer.disposeTemplate(e.templateData)}dispose(){this.renderedNodes.clear(),this.disposables=(0,a.AS)(this.disposables)}}class re extends ie{constructor(e,t,i,s,n,r,o={}){super(e,t,i,n,r,o),this.compressionDelegate=s,this.compressibleNodeMapper=new E.y2((e=>new se(e))),this.filter=o.filter}createTree(e,t,i,s,n){const r=new v.w0(i),o=s.map((e=>new ne(e,this.nodeMapper,(()=>this.compressibleNodeMapper),this._onDidChangeNodeSlowState.event))),a=function(e){const t=e&&ee(e);return t&&{...t,keyboardNavigationLabelProvider:t.keyboardNavigationLabelProvider&&{...t.keyboardNavigationLabelProvider,getCompressedNodeKeyboardNavigationLabel:t=>e.keyboardNavigationLabelProvider.getCompressedNodeKeyboardNavigationLabel(t.map((e=>e.element)))}}}(n)||{};return new H(e,t,r,o,a)}asTreeElement(e,t){return{incompressible:this.compressionDelegate.isIncompressible(e.element),...super.asTreeElement(e,t)}}updateOptions(e={}){this.tree.updateOptions(e)}render(e,t,i){if(!this.identityProvider)return super.render(e,t);const s=e=>this.identityProvider.getId(e).toString(),n=e=>{const t=new Set;for(const i of e){const e=this.tree.getCompressedTreeNode(i===this.root?null:i);if(e.element)for(const i of e.element.elements)t.add(s(i.element))}return t},r=n(this.tree.getSelection()),o=n(this.tree.getFocus());super.render(e,t,i);const a=this.getSelection();let l=!1;const c=this.getFocus();let h=!1;const d=e=>{const t=e.element;if(t)for(let i=0;i{const t=this.filter.filter(e,1),i="boolean"===typeof(s=t)?s?1:0:(0,b.iZ)(s)?(0,b.Mn)(s.visibility):(0,b.Mn)(s);var s;if(2===i)throw new Error("Recursive tree visibility not supported in async data compressed trees");return 1===i}))),super.processChildren(e)}}class oe extends v.DO{constructor(e,t,i,s,n,r={}){super(e,t,i,s,r),this.user=e,this.dataSource=n,this.identityProvider=r.identityProvider}createModel(e,t,i){return new y(e,t,i)}}var ae=i(78209),le=i(84001),ce=i(1646),he=i(32848),de=i(28290),ue=i(47508),ge=i(63591),pe=i(98031),me=i(46359),fe=i(19070),_e=function(e,t,i,s){var n,r=arguments.length,o=r<3?t:null===s?s=Object.getOwnPropertyDescriptor(t,i):s;if("object"===typeof Reflect&&"function"===typeof Reflect.decorate)o=Reflect.decorate(e,t,i,s);else for(var a=e.length-1;a>=0;a--)(n=e[a])&&(o=(r<3?n(o):r>3?n(t,i,o):n(t,i))||o);return r>3&&o&&Object.defineProperty(t,i,o),o},ve=function(e,t){return function(i,s){t(i,s,e)}};const Ce=(0,ge.u1)("listService");class be{get lastFocusedList(){return this._lastFocusedWidget}constructor(){this.disposables=new a.Cm,this.lists=[],this._lastFocusedWidget=void 0,this._hasCreatedStyleController=!1}setLastFocusedList(e){e!==this._lastFocusedWidget&&(this._lastFocusedWidget?.getHTMLElement().classList.remove("last-focused"),this._lastFocusedWidget=e,this._lastFocusedWidget?.getHTMLElement().classList.add("last-focused"))}register(e,t){if(!this._hasCreatedStyleController){this._hasCreatedStyleController=!0;new l.hb((0,s.li)(),"").style(fe.IN)}if(this.lists.some((t=>t.widget===e)))throw new Error("Cannot register the same widget multiple times");const i={widget:e,extraContextKeys:t};return this.lists.push(i),(0,s.X7)(e.getHTMLElement())&&this.setLastFocusedList(e),(0,a.qE)(e.onDidFocus((()=>this.setLastFocusedList(e))),(0,a.s)((()=>this.lists.splice(this.lists.indexOf(i),1))),e.onDidDispose((()=>{this.lists=this.lists.filter((e=>e!==i)),this._lastFocusedWidget===e&&this.setLastFocusedList(void 0)})))}dispose(){this.disposables.dispose()}}const Ee=new he.N1("listScrollAtBoundary","none"),Se=(he.M$.or(Ee.isEqualTo("top"),Ee.isEqualTo("both")),he.M$.or(Ee.isEqualTo("bottom"),Ee.isEqualTo("both")),new he.N1("listFocus",!0)),ye=new he.N1("treestickyScrollFocused",!1),we=new he.N1("listSupportsMultiselect",!0),Le=he.M$.and(Se,he.M$.not(de.aV),ye.negate()),Re=new he.N1("listHasSelectionOrFocus",!1),Te=new he.N1("listDoubleSelection",!1),xe=new he.N1("listMultiSelection",!1),ke=new he.N1("listSelectionNavigation",!1),Ae=new he.N1("listSupportsFind",!0),Ne=new he.N1("treeElementCanCollapse",!1),Ie=new he.N1("treeElementHasParent",!1),Oe=new he.N1("treeElementCanExpand",!1),De=new he.N1("treeElementHasChild",!1),Me=new he.N1("treeFindOpen",!1),Pe="listTypeNavigationMode",Fe="listAutomaticKeyboardNavigation";function Ue(e,t){const i=e.createScoped(t.getHTMLElement());return Se.bindTo(i),i}function He(e,t){const i=Ee.bindTo(e),s=()=>{const e=0===t.scrollTop,s=t.scrollHeight-t.renderHeight-t.scrollTop<1;e&&s?i.set("both"):e?i.set("top"):s?i.set("bottom"):i.set("none")};return s(),t.onDidScroll(s)}const Be="workbench.list.multiSelectModifier",We="workbench.list.openMode",Ve="workbench.list.horizontalScrolling",ze="workbench.list.defaultFindMode",Ge="workbench.list.typeNavigationMode",je="workbench.list.keyboardNavigation",Ke="workbench.list.scrollByPage",Ye="workbench.list.defaultFindMatchType",qe="workbench.tree.indent",$e="workbench.tree.renderIndentGuides",Qe="workbench.list.smoothScrolling",Xe="workbench.list.mouseWheelScrollSensitivity",Ze="workbench.list.fastScrollSensitivity",Je="workbench.tree.expandMode",et="workbench.tree.enableStickyScroll",tt="workbench.tree.stickyScrollMaxItemCount";function it(e){return"alt"===e.getValue(Be)}class st extends a.jG{constructor(e){super(),this.configurationService=e,this.useAltAsMultipleSelectionModifier=it(e),this.registerListeners()}registerListeners(){this._register(this.configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration(Be)&&(this.useAltAsMultipleSelectionModifier=it(this.configurationService))})))}isSelectionSingleChangeEvent(e){return this.useAltAsMultipleSelectionModifier?e.browserEvent.altKey:(0,l.tX)(e)}isSelectionRangeChangeEvent(e){return(0,l.mh)(e)}}function nt(e,t){const i=e.get(le.pG),s=e.get(pe.b),n=new a.Cm;return[{...t,keyboardNavigationDelegate:{mightProducePrintableCharacter:e=>s.mightProducePrintableCharacter(e)},smoothScrolling:Boolean(i.getValue(Qe)),mouseWheelScrollSensitivity:i.getValue(Xe),fastScrollSensitivity:i.getValue(Ze),multipleSelectionController:t.multipleSelectionController??n.add(new st(i)),keyboardNavigationEventFilter:ut(s),scrollByPage:Boolean(i.getValue(Ke))},n]}let rt=class extends l.B8{constructor(e,t,i,s,n,r,o,a,l){const c="undefined"!==typeof n.horizontalScrolling?n.horizontalScrolling:Boolean(a.getValue(Ve)),[h,d]=l.invokeFunction(nt,n);super(e,t,i,s,{keyboardSupport:!1,...h,horizontalScrolling:c}),this.disposables.add(d),this.contextKeyService=Ue(r,this),this.disposables.add(He(this.contextKeyService,this)),this.listSupportsMultiSelect=we.bindTo(this.contextKeyService),this.listSupportsMultiSelect.set(!1!==n.multipleSelectionSupport);ke.bindTo(this.contextKeyService).set(Boolean(n.selectionNavigation)),this.listHasSelectionOrFocus=Re.bindTo(this.contextKeyService),this.listDoubleSelection=Te.bindTo(this.contextKeyService),this.listMultiSelection=xe.bindTo(this.contextKeyService),this.horizontalScrolling=n.horizontalScrolling,this._useAltAsMultipleSelectionModifier=it(a),this.disposables.add(this.contextKeyService),this.disposables.add(o.register(this)),this.updateStyles(n.overrideStyles),this.disposables.add(this.onDidChangeSelection((()=>{const e=this.getSelection(),t=this.getFocus();this.contextKeyService.bufferChangeEvents((()=>{this.listHasSelectionOrFocus.set(e.length>0||t.length>0),this.listMultiSelection.set(e.length>1),this.listDoubleSelection.set(2===e.length)}))}))),this.disposables.add(this.onDidChangeFocus((()=>{const e=this.getSelection(),t=this.getFocus();this.listHasSelectionOrFocus.set(e.length>0||t.length>0)}))),this.disposables.add(a.onDidChangeConfiguration((e=>{e.affectsConfiguration(Be)&&(this._useAltAsMultipleSelectionModifier=it(a));let t={};if(e.affectsConfiguration(Ve)&&void 0===this.horizontalScrolling){const e=Boolean(a.getValue(Ve));t={...t,horizontalScrolling:e}}if(e.affectsConfiguration(Ke)){const e=Boolean(a.getValue(Ke));t={...t,scrollByPage:e}}if(e.affectsConfiguration(Qe)){const e=Boolean(a.getValue(Qe));t={...t,smoothScrolling:e}}if(e.affectsConfiguration(Xe)){const e=a.getValue(Xe);t={...t,mouseWheelScrollSensitivity:e}}if(e.affectsConfiguration(Ze)){const e=a.getValue(Ze);t={...t,fastScrollSensitivity:e}}Object.keys(t).length>0&&this.updateOptions(t)}))),this.navigator=new ct(this,{configurationService:a,...n}),this.disposables.add(this.navigator)}updateOptions(e){super.updateOptions(e),void 0!==e.overrideStyles&&this.updateStyles(e.overrideStyles),void 0!==e.multipleSelectionSupport&&this.listSupportsMultiSelect.set(!!e.multipleSelectionSupport)}updateStyles(e){this.style(e?(0,fe.t8)(e):fe.IN)}};rt=_e([ve(5,he.fN),ve(6,Ce),ve(7,le.pG),ve(8,ge._Y)],rt);let ot=class extends d{constructor(e,t,i,s,n,r,o,l,c){const h="undefined"!==typeof n.horizontalScrolling?n.horizontalScrolling:Boolean(l.getValue(Ve)),[d,u]=c.invokeFunction(nt,n);super(e,t,i,s,{keyboardSupport:!1,...d,horizontalScrolling:h}),this.disposables=new a.Cm,this.disposables.add(u),this.contextKeyService=Ue(r,this),this.disposables.add(He(this.contextKeyService,this.widget)),this.horizontalScrolling=n.horizontalScrolling,this.listSupportsMultiSelect=we.bindTo(this.contextKeyService),this.listSupportsMultiSelect.set(!1!==n.multipleSelectionSupport);ke.bindTo(this.contextKeyService).set(Boolean(n.selectionNavigation)),this._useAltAsMultipleSelectionModifier=it(l),this.disposables.add(this.contextKeyService),this.disposables.add(o.register(this)),this.updateStyles(n.overrideStyles),this.disposables.add(l.onDidChangeConfiguration((e=>{e.affectsConfiguration(Be)&&(this._useAltAsMultipleSelectionModifier=it(l));let t={};if(e.affectsConfiguration(Ve)&&void 0===this.horizontalScrolling){const e=Boolean(l.getValue(Ve));t={...t,horizontalScrolling:e}}if(e.affectsConfiguration(Ke)){const e=Boolean(l.getValue(Ke));t={...t,scrollByPage:e}}if(e.affectsConfiguration(Qe)){const e=Boolean(l.getValue(Qe));t={...t,smoothScrolling:e}}if(e.affectsConfiguration(Xe)){const e=l.getValue(Xe);t={...t,mouseWheelScrollSensitivity:e}}if(e.affectsConfiguration(Ze)){const e=l.getValue(Ze);t={...t,fastScrollSensitivity:e}}Object.keys(t).length>0&&this.updateOptions(t)}))),this.navigator=new ct(this,{configurationService:l,...n}),this.disposables.add(this.navigator)}updateOptions(e){super.updateOptions(e),void 0!==e.overrideStyles&&this.updateStyles(e.overrideStyles),void 0!==e.multipleSelectionSupport&&this.listSupportsMultiSelect.set(!!e.multipleSelectionSupport)}updateStyles(e){this.style(e?(0,fe.t8)(e):fe.IN)}dispose(){this.disposables.dispose(),super.dispose()}};ot=_e([ve(5,he.fN),ve(6,Ce),ve(7,le.pG),ve(8,ge._Y)],ot);let at=class extends _{constructor(e,t,i,s,n,r,o,a,l,c){const h="undefined"!==typeof r.horizontalScrolling?r.horizontalScrolling:Boolean(l.getValue(Ve)),[d,u]=c.invokeFunction(nt,r);super(e,t,i,s,n,{keyboardSupport:!1,...d,horizontalScrolling:h}),this.disposables.add(u),this.contextKeyService=Ue(o,this),this.disposables.add(He(this.contextKeyService,this)),this.listSupportsMultiSelect=we.bindTo(this.contextKeyService),this.listSupportsMultiSelect.set(!1!==r.multipleSelectionSupport);ke.bindTo(this.contextKeyService).set(Boolean(r.selectionNavigation)),this.listHasSelectionOrFocus=Re.bindTo(this.contextKeyService),this.listDoubleSelection=Te.bindTo(this.contextKeyService),this.listMultiSelection=xe.bindTo(this.contextKeyService),this.horizontalScrolling=r.horizontalScrolling,this._useAltAsMultipleSelectionModifier=it(l),this.disposables.add(this.contextKeyService),this.disposables.add(a.register(this)),this.updateStyles(r.overrideStyles),this.disposables.add(this.onDidChangeSelection((()=>{const e=this.getSelection(),t=this.getFocus();this.contextKeyService.bufferChangeEvents((()=>{this.listHasSelectionOrFocus.set(e.length>0||t.length>0),this.listMultiSelection.set(e.length>1),this.listDoubleSelection.set(2===e.length)}))}))),this.disposables.add(this.onDidChangeFocus((()=>{const e=this.getSelection(),t=this.getFocus();this.listHasSelectionOrFocus.set(e.length>0||t.length>0)}))),this.disposables.add(l.onDidChangeConfiguration((e=>{e.affectsConfiguration(Be)&&(this._useAltAsMultipleSelectionModifier=it(l));let t={};if(e.affectsConfiguration(Ve)&&void 0===this.horizontalScrolling){const e=Boolean(l.getValue(Ve));t={...t,horizontalScrolling:e}}if(e.affectsConfiguration(Ke)){const e=Boolean(l.getValue(Ke));t={...t,scrollByPage:e}}if(e.affectsConfiguration(Qe)){const e=Boolean(l.getValue(Qe));t={...t,smoothScrolling:e}}if(e.affectsConfiguration(Xe)){const e=l.getValue(Xe);t={...t,mouseWheelScrollSensitivity:e}}if(e.affectsConfiguration(Ze)){const e=l.getValue(Ze);t={...t,fastScrollSensitivity:e}}Object.keys(t).length>0&&this.updateOptions(t)}))),this.navigator=new ht(this,{configurationService:l,...r}),this.disposables.add(this.navigator)}updateOptions(e){super.updateOptions(e),void 0!==e.overrideStyles&&this.updateStyles(e.overrideStyles),void 0!==e.multipleSelectionSupport&&this.listSupportsMultiSelect.set(!!e.multipleSelectionSupport)}updateStyles(e){this.style(e?(0,fe.t8)(e):fe.IN)}dispose(){this.disposables.dispose(),super.dispose()}};at=_e([ve(6,he.fN),ve(7,Ce),ve(8,le.pG),ve(9,ge._Y)],at);class lt extends a.jG{constructor(e,t){super(),this.widget=e,this._onDidOpen=this._register(new o.vl),this.onDidOpen=this._onDidOpen.event,this._register(o.Jh.filter(this.widget.onDidChangeSelection,(e=>(0,s.kx)(e.browserEvent)))((e=>this.onSelectionFromKeyboard(e)))),this._register(this.widget.onPointer((e=>this.onPointer(e.element,e.browserEvent)))),this._register(this.widget.onMouseDblClick((e=>this.onMouseDblClick(e.element,e.browserEvent)))),"boolean"!==typeof t?.openOnSingleClick&&t?.configurationService?(this.openOnSingleClick="doubleClick"!==t?.configurationService.getValue(We),this._register(t?.configurationService.onDidChangeConfiguration((e=>{e.affectsConfiguration(We)&&(this.openOnSingleClick="doubleClick"!==t?.configurationService.getValue(We))})))):this.openOnSingleClick=t?.openOnSingleClick??!0}onSelectionFromKeyboard(e){if(1!==e.elements.length)return;const t=e.browserEvent,i="boolean"!==typeof t.preserveFocus||t.preserveFocus,s="boolean"===typeof t.pinned?t.pinned:!i;this._open(this.getSelectedElement(),i,s,!1,e.browserEvent)}onPointer(e,t){if(!this.openOnSingleClick)return;if(2===t.detail)return;const i=1===t.button,s=t.ctrlKey||t.metaKey||t.altKey;this._open(e,!0,i,s,t)}onMouseDblClick(e,t){if(!t)return;const i=t.target;if(i.classList.contains("monaco-tl-twistie")||i.classList.contains("monaco-icon-label")&&i.classList.contains("folder-icon")&&t.offsetX<16)return;const s=t.ctrlKey||t.metaKey||t.altKey;this._open(e,!1,!0,s,t)}_open(e,t,i,s,n){e&&this._onDidOpen.fire({editorOptions:{preserveFocus:t,pinned:i,revealIfVisible:!0},sideBySide:s,element:e,browserEvent:n})}}class ct extends lt{constructor(e,t){super(e,t),this.widget=e}getSelectedElement(){return this.widget.getSelectedElements()[0]}}class ht extends lt{constructor(e,t){super(e,t)}getSelectedElement(){return this.widget.getSelectedElements()[0]}}class dt extends lt{constructor(e,t){super(e,t)}getSelectedElement(){return this.widget.getSelection()[0]??void 0}}function ut(e){let t=!1;return i=>{if(i.toKeyCodeChord().isModifierKey())return!1;if(t)return t=!1,!1;const s=e.softDispatch(i,i.target);return 1===s.kind?(t=!0,!1):(t=!1,0===s.kind)}}let gt=class extends M{constructor(e,t,i,s,n,r,o,a,l){const{options:c,getTypeNavigationMode:h,disposable:d}=r.invokeFunction(bt,n);super(e,t,i,s,c),this.disposables.add(d),this.internals=new Et(this,n,h,n.overrideStyles,o,a,l),this.disposables.add(this.internals)}updateOptions(e){super.updateOptions(e),this.internals.updateOptions(e)}};gt=_e([ve(5,ge._Y),ve(6,he.fN),ve(7,Ce),ve(8,le.pG)],gt);let pt=class extends H{constructor(e,t,i,s,n,r,o,a,l){const{options:c,getTypeNavigationMode:h,disposable:d}=r.invokeFunction(bt,n);super(e,t,i,s,c),this.disposables.add(d),this.internals=new Et(this,n,h,n.overrideStyles,o,a,l),this.disposables.add(this.internals)}updateOptions(e={}){super.updateOptions(e),e.overrideStyles&&this.internals.updateStyleOverrides(e.overrideStyles),this.internals.updateOptions(e)}};pt=_e([ve(5,ge._Y),ve(6,he.fN),ve(7,Ce),ve(8,le.pG)],pt);let mt=class extends oe{constructor(e,t,i,s,n,r,o,a,l,c){const{options:h,getTypeNavigationMode:d,disposable:u}=o.invokeFunction(bt,r);super(e,t,i,s,n,h),this.disposables.add(u),this.internals=new Et(this,r,d,r.overrideStyles,a,l,c),this.disposables.add(this.internals)}updateOptions(e={}){super.updateOptions(e),void 0!==e.overrideStyles&&this.internals.updateStyleOverrides(e.overrideStyles),this.internals.updateOptions(e)}};mt=_e([ve(6,ge._Y),ve(7,he.fN),ve(8,Ce),ve(9,le.pG)],mt);let ft=class extends ie{get onDidOpen(){return this.internals.onDidOpen}constructor(e,t,i,s,n,r,o,a,l,c){const{options:h,getTypeNavigationMode:d,disposable:u}=o.invokeFunction(bt,r);super(e,t,i,s,n,h),this.disposables.add(u),this.internals=new Et(this,r,d,r.overrideStyles,a,l,c),this.disposables.add(this.internals)}updateOptions(e={}){super.updateOptions(e),e.overrideStyles&&this.internals.updateStyleOverrides(e.overrideStyles),this.internals.updateOptions(e)}};ft=_e([ve(6,ge._Y),ve(7,he.fN),ve(8,Ce),ve(9,le.pG)],ft);let _t=class extends re{constructor(e,t,i,s,n,r,o,a,l,c,h){const{options:d,getTypeNavigationMode:u,disposable:g}=a.invokeFunction(bt,o);super(e,t,i,s,n,r,d),this.disposables.add(g),this.internals=new Et(this,o,u,o.overrideStyles,l,c,h),this.disposables.add(this.internals)}updateOptions(e){super.updateOptions(e),this.internals.updateOptions(e)}};function vt(e){const t=e.getValue(ze);if("highlight"===t)return v.vD.Highlight;if("filter"===t)return v.vD.Filter;const i=e.getValue(je);return"simple"===i||"highlight"===i?v.vD.Highlight:"filter"===i?v.vD.Filter:void 0}function Ct(e){const t=e.getValue(Ye);return"fuzzy"===t?v.RD.Fuzzy:"contiguous"===t?v.RD.Contiguous:void 0}function bt(e,t){const i=e.get(le.pG),s=e.get(ue.l),n=e.get(he.fN),r=e.get(ge._Y),o=void 0!==t.horizontalScrolling?t.horizontalScrolling:Boolean(i.getValue(Ve)),[a,c]=r.invokeFunction(nt,t),h=t.paddingBottom,d=void 0!==t.renderIndentGuides?t.renderIndentGuides:i.getValue($e);return{getTypeNavigationMode:()=>{const e=n.getContextKeyValue(Pe);if("automatic"===e)return l._C.Automatic;if("trigger"===e)return l._C.Trigger;if(!1===n.getContextKeyValue(Fe))return l._C.Trigger;const t=i.getValue(Ge);return"automatic"===t?l._C.Automatic:"trigger"===t?l._C.Trigger:void 0},disposable:c,options:{keyboardSupport:!1,...a,indent:"number"===typeof i.getValue(qe)?i.getValue(qe):void 0,renderIndentGuides:d,smoothScrolling:Boolean(i.getValue(Qe)),defaultFindMode:vt(i),defaultFindMatchType:Ct(i),horizontalScrolling:o,scrollByPage:Boolean(i.getValue(Ke)),paddingBottom:h,hideTwistiesOfChildlessElements:t.hideTwistiesOfChildlessElements,expandOnlyOnTwistieClick:t.expandOnlyOnTwistieClick??"doubleClick"===i.getValue(Je),contextViewProvider:s,findWidgetStyles:fe.Dk,enableStickyScroll:Boolean(i.getValue(et)),stickyScrollMaxItemCount:Number(i.getValue(tt))}}}_t=_e([ve(7,ge._Y),ve(8,he.fN),ve(9,Ce),ve(10,le.pG)],_t);let Et=class{get onDidOpen(){return this.navigator.onDidOpen}constructor(e,t,i,s,n,r,o){this.tree=e,this.disposables=[],this.contextKeyService=Ue(n,e),this.disposables.push(He(this.contextKeyService,e)),this.listSupportsMultiSelect=we.bindTo(this.contextKeyService),this.listSupportsMultiSelect.set(!1!==t.multipleSelectionSupport);ke.bindTo(this.contextKeyService).set(Boolean(t.selectionNavigation)),this.listSupportFindWidget=Ae.bindTo(this.contextKeyService),this.listSupportFindWidget.set(t.findWidgetEnabled??!0),this.hasSelectionOrFocus=Re.bindTo(this.contextKeyService),this.hasDoubleSelection=Te.bindTo(this.contextKeyService),this.hasMultiSelection=xe.bindTo(this.contextKeyService),this.treeElementCanCollapse=Ne.bindTo(this.contextKeyService),this.treeElementHasParent=Ie.bindTo(this.contextKeyService),this.treeElementCanExpand=Oe.bindTo(this.contextKeyService),this.treeElementHasChild=De.bindTo(this.contextKeyService),this.treeFindOpen=Me.bindTo(this.contextKeyService),this.treeStickyScrollFocused=ye.bindTo(this.contextKeyService),this._useAltAsMultipleSelectionModifier=it(o),this.updateStyleOverrides(s);const a=()=>{const t=e.getFocus()[0];if(!t)return;const i=e.getNode(t);this.treeElementCanCollapse.set(i.collapsible&&!i.collapsed),this.treeElementHasParent.set(!!e.getParentElement(t)),this.treeElementCanExpand.set(i.collapsible&&i.collapsed),this.treeElementHasChild.set(!!e.getFirstElementChild(t))},l=new Set;l.add(Pe),l.add(Fe),this.disposables.push(this.contextKeyService,r.register(e),e.onDidChangeSelection((()=>{const t=e.getSelection(),i=e.getFocus();this.contextKeyService.bufferChangeEvents((()=>{this.hasSelectionOrFocus.set(t.length>0||i.length>0),this.hasMultiSelection.set(t.length>1),this.hasDoubleSelection.set(2===t.length)}))})),e.onDidChangeFocus((()=>{const t=e.getSelection(),i=e.getFocus();this.hasSelectionOrFocus.set(t.length>0||i.length>0),a()})),e.onDidChangeCollapseState(a),e.onDidChangeModel(a),e.onDidChangeFindOpenState((e=>this.treeFindOpen.set(e))),e.onDidChangeStickyScrollFocused((e=>this.treeStickyScrollFocused.set(e))),o.onDidChangeConfiguration((s=>{let n={};if(s.affectsConfiguration(Be)&&(this._useAltAsMultipleSelectionModifier=it(o)),s.affectsConfiguration(qe)){const e=o.getValue(qe);n={...n,indent:e}}if(s.affectsConfiguration($e)&&void 0===t.renderIndentGuides){const e=o.getValue($e);n={...n,renderIndentGuides:e}}if(s.affectsConfiguration(Qe)){const e=Boolean(o.getValue(Qe));n={...n,smoothScrolling:e}}if(s.affectsConfiguration(ze)||s.affectsConfiguration(je)){const e=vt(o);n={...n,defaultFindMode:e}}if(s.affectsConfiguration(Ge)||s.affectsConfiguration(je)){const e=i();n={...n,typeNavigationMode:e}}if(s.affectsConfiguration(Ye)){const e=Ct(o);n={...n,defaultFindMatchType:e}}if(s.affectsConfiguration(Ve)&&void 0===t.horizontalScrolling){const e=Boolean(o.getValue(Ve));n={...n,horizontalScrolling:e}}if(s.affectsConfiguration(Ke)){const e=Boolean(o.getValue(Ke));n={...n,scrollByPage:e}}if(s.affectsConfiguration(Je)&&void 0===t.expandOnlyOnTwistieClick&&(n={...n,expandOnlyOnTwistieClick:"doubleClick"===o.getValue(Je)}),s.affectsConfiguration(et)){const e=o.getValue(et);n={...n,enableStickyScroll:e}}if(s.affectsConfiguration(tt)){const e=Math.max(1,o.getValue(tt));n={...n,stickyScrollMaxItemCount:e}}if(s.affectsConfiguration(Xe)){const e=o.getValue(Xe);n={...n,mouseWheelScrollSensitivity:e}}if(s.affectsConfiguration(Ze)){const e=o.getValue(Ze);n={...n,fastScrollSensitivity:e}}Object.keys(n).length>0&&e.updateOptions(n)})),this.contextKeyService.onDidChangeContext((t=>{t.affectsSome(l)&&e.updateOptions({typeNavigationMode:i()})}))),this.navigator=new dt(e,{configurationService:o,...t}),this.disposables.push(this.navigator)}updateOptions(e){void 0!==e.multipleSelectionSupport&&this.listSupportsMultiSelect.set(!!e.multipleSelectionSupport)}updateStyleOverrides(e){this.tree.style(e?(0,fe.t8)(e):fe.IN)}dispose(){this.disposables=(0,a.AS)(this.disposables)}};Et=_e([ve(4,he.fN),ve(5,Ce),ve(6,le.pG)],Et);me.O.as(ce.Fd.Configuration).registerConfiguration({id:"workbench",order:7,title:(0,ae.kg)("workbenchConfigurationTitle","Workbench"),type:"object",properties:{[Be]:{type:"string",enum:["ctrlCmd","alt"],markdownEnumDescriptions:[(0,ae.kg)("multiSelectModifier.ctrlCmd","Maps to `Control` on Windows and Linux and to `Command` on macOS."),(0,ae.kg)("multiSelectModifier.alt","Maps to `Alt` on Windows and Linux and to `Option` on macOS.")],default:"ctrlCmd",description:(0,ae.kg)({key:"multiSelectModifier",comment:["- `ctrlCmd` refers to a value the setting can take and should not be localized.","- `Control` and `Command` refer to the modifier keys Ctrl or Cmd on the keyboard and can be localized."]},"The modifier to be used to add an item in trees and lists to a multi-selection with the mouse (for example in the explorer, open editors and scm view). The 'Open to Side' mouse gestures - if supported - will adapt such that they do not conflict with the multiselect modifier.")},[We]:{type:"string",enum:["singleClick","doubleClick"],default:"singleClick",description:(0,ae.kg)({key:"openModeModifier",comment:["`singleClick` and `doubleClick` refers to a value the setting can take and should not be localized."]},"Controls how to open items in trees and lists using the mouse (if supported). Note that some trees and lists might choose to ignore this setting if it is not applicable.")},[Ve]:{type:"boolean",default:!1,description:(0,ae.kg)("horizontalScrolling setting","Controls whether lists and trees support horizontal scrolling in the workbench. Warning: turning on this setting has a performance implication.")},[Ke]:{type:"boolean",default:!1,description:(0,ae.kg)("list.scrollByPage","Controls whether clicks in the scrollbar scroll page by page.")},[qe]:{type:"number",default:8,minimum:4,maximum:40,description:(0,ae.kg)("tree indent setting","Controls tree indentation in pixels.")},[$e]:{type:"string",enum:["none","onHover","always"],default:"onHover",description:(0,ae.kg)("render tree indent guides","Controls whether the tree should render indent guides.")},[Qe]:{type:"boolean",default:!1,description:(0,ae.kg)("list smoothScrolling setting","Controls whether lists and trees have smooth scrolling.")},[Xe]:{type:"number",default:1,markdownDescription:(0,ae.kg)("Mouse Wheel Scroll Sensitivity","A multiplier to be used on the `deltaX` and `deltaY` of mouse wheel scroll events.")},[Ze]:{type:"number",default:5,markdownDescription:(0,ae.kg)("Fast Scroll Sensitivity","Scrolling speed multiplier when pressing `Alt`.")},[ze]:{type:"string",enum:["highlight","filter"],enumDescriptions:[(0,ae.kg)("defaultFindModeSettingKey.highlight","Highlight elements when searching. Further up and down navigation will traverse only the highlighted elements."),(0,ae.kg)("defaultFindModeSettingKey.filter","Filter elements when searching.")],default:"highlight",description:(0,ae.kg)("defaultFindModeSettingKey","Controls the default find mode for lists and trees in the workbench.")},[je]:{type:"string",enum:["simple","highlight","filter"],enumDescriptions:[(0,ae.kg)("keyboardNavigationSettingKey.simple","Simple keyboard navigation focuses elements which match the keyboard input. Matching is done only on prefixes."),(0,ae.kg)("keyboardNavigationSettingKey.highlight","Highlight keyboard navigation highlights elements which match the keyboard input. Further up and down navigation will traverse only the highlighted elements."),(0,ae.kg)("keyboardNavigationSettingKey.filter","Filter keyboard navigation will filter out and hide all the elements which do not match the keyboard input.")],default:"highlight",description:(0,ae.kg)("keyboardNavigationSettingKey","Controls the keyboard navigation style for lists and trees in the workbench. Can be simple, highlight and filter."),deprecated:!0,deprecationMessage:(0,ae.kg)("keyboardNavigationSettingKeyDeprecated","Please use 'workbench.list.defaultFindMode' and\t'workbench.list.typeNavigationMode' instead.")},[Ye]:{type:"string",enum:["fuzzy","contiguous"],enumDescriptions:[(0,ae.kg)("defaultFindMatchTypeSettingKey.fuzzy","Use fuzzy matching when searching."),(0,ae.kg)("defaultFindMatchTypeSettingKey.contiguous","Use contiguous matching when searching.")],default:"fuzzy",description:(0,ae.kg)("defaultFindMatchTypeSettingKey","Controls the type of matching used when searching lists and trees in the workbench.")},[Je]:{type:"string",enum:["singleClick","doubleClick"],default:"singleClick",description:(0,ae.kg)("expand mode","Controls how tree folders are expanded when clicking the folder names. Note that some trees and lists might choose to ignore this setting if it is not applicable.")},[et]:{type:"boolean",default:!0,description:(0,ae.kg)("sticky scroll","Controls whether sticky scrolling is enabled in trees.")},[tt]:{type:"number",minimum:1,default:7,markdownDescription:(0,ae.kg)("sticky scroll maximum items","Controls the number of sticky elements displayed in the tree when {0} is enabled.","`#workbench.tree.enableStickyScroll#`")},[Ge]:{type:"string",enum:["automatic","trigger"],default:"automatic",markdownDescription:(0,ae.kg)("typeNavigationMode2","Controls how type navigation works in lists and trees in the workbench. When set to `trigger`, type navigation begins once the `list.triggerTypeNavigation` command is run.")}}})},18801:(e,t,i)=>{"use strict";i.d(t,{$b:()=>a,Cr:()=>h,Dk:()=>d,rr:()=>o});var s=i(41234),n=i(5662),r=i(32848);const o=(0,i(63591).u1)("logService");var a;!function(e){e[e.Off=0]="Off",e[e.Trace=1]="Trace",e[e.Debug=2]="Debug",e[e.Info=3]="Info",e[e.Warning=4]="Warning",e[e.Error=5]="Error"}(a||(a={}));const l=a.Info;class c extends n.jG{constructor(){super(...arguments),this.level=l,this._onDidChangeLogLevel=this._register(new s.vl),this.onDidChangeLogLevel=this._onDidChangeLogLevel.event}setLevel(e){this.level!==e&&(this.level=e,this._onDidChangeLogLevel.fire(this.level))}getLevel(){return this.level}checkLogLevel(e){return this.level!==a.Off&&this.level<=e}}class h extends c{constructor(e=l,t=!0){super(),this.useColors=t,this.setLevel(e)}trace(e,...t){this.checkLogLevel(a.Trace)&&(this.useColors?console.log("%cTRACE","color: #888",e,...t):console.log(e,...t))}debug(e,...t){this.checkLogLevel(a.Debug)&&(this.useColors?console.log("%cDEBUG","background: #eee; color: #888",e,...t):console.log(e,...t))}info(e,...t){this.checkLogLevel(a.Info)&&(this.useColors?console.log("%c INFO","color: #33f",e,...t):console.log(e,...t))}warn(e,...t){this.checkLogLevel(a.Warning)&&(this.useColors?console.log("%c WARN","color: #993",e,...t):console.log(e,...t))}error(e,...t){this.checkLogLevel(a.Error)&&(this.useColors?console.log("%c ERR","color: #f33",e,...t):console.error(e,...t))}}class d extends c{constructor(e){super(),this.loggers=e,e.length&&this.setLevel(e[0].getLevel())}setLevel(e){for(const t of this.loggers)t.setLevel(e);super.setLevel(e)}trace(e,...t){for(const i of this.loggers)i.trace(e,...t)}debug(e,...t){for(const i of this.loggers)i.debug(e,...t)}info(e,...t){for(const i of this.loggers)i.info(e,...t)}warn(e,...t){for(const i of this.loggers)i.warn(e,...t)}error(e,...t){for(const i of this.loggers)i.error(e,...t)}dispose(){for(const e of this.loggers)e.dispose();super.dispose()}}new r.N1("logLevel",function(e){switch(e){case a.Trace:return"trace";case a.Debug:return"debug";case a.Info:return"info";case a.Warning:return"warn";case a.Error:return"error";case a.Off:return"off"}}(a.Info))},75147:(e,t,i)=>{"use strict";i.d(t,{DR:()=>l,cj:()=>s,oc:()=>n});var s,n,r=i(42291),o=i(78209),a=i(63591);!function(e){e[e.Hint=1]="Hint",e[e.Info=2]="Info",e[e.Warning=4]="Warning",e[e.Error=8]="Error"}(s||(s={})),function(e){e.compare=function(e,t){return t-e};const t=Object.create(null);t[e.Error]=(0,o.kg)("sev.error","Error"),t[e.Warning]=(0,o.kg)("sev.warning","Warning"),t[e.Info]=(0,o.kg)("sev.info","Info"),e.toString=function(e){return t[e]||""},e.fromSeverity=function(t){switch(t){case r.A.Error:return e.Error;case r.A.Warning:return e.Warning;case r.A.Info:return e.Info;case r.A.Ignore:return e.Hint}},e.toSeverity=function(t){switch(t){case e.Error:return r.A.Error;case e.Warning:return r.A.Warning;case e.Info:return r.A.Info;case e.Hint:return r.A.Ignore}}}(s||(s={})),function(e){const t="";function i(e,i){const n=[t];return e.source?n.push(e.source.replace("\xa6","\\\xa6")):n.push(t),e.code?"string"===typeof e.code?n.push(e.code.replace("\xa6","\\\xa6")):n.push(e.code.value.replace("\xa6","\\\xa6")):n.push(t),void 0!==e.severity&&null!==e.severity?n.push(s.toString(e.severity)):n.push(t),e.message&&i?n.push(e.message.replace("\xa6","\\\xa6")):n.push(t),void 0!==e.startLineNumber&&null!==e.startLineNumber?n.push(e.startLineNumber.toString()):n.push(t),void 0!==e.startColumn&&null!==e.startColumn?n.push(e.startColumn.toString()):n.push(t),void 0!==e.endLineNumber&&null!==e.endLineNumber?n.push(e.endLineNumber.toString()):n.push(t),void 0!==e.endColumn&&null!==e.endColumn?n.push(e.endColumn.toString()):n.push(t),n.push(t),n.join("\xa6")}e.makeKey=function(e){return i(e,!0)},e.makeKeyOptionalMessage=i}(n||(n={}));const l=(0,a.u1)("markerService")},58591:(e,t,i)=>{"use strict";i.d(t,{AI:()=>r,Kz:()=>a,Ot:()=>o});var s=i(42291),n=i(63591),r=s.A;const o=(0,n.u1)("notificationService");class a{}},71319:(e,t,i)=>{"use strict";i.d(t,{V:()=>r,w:()=>o});var s=i(31308),n=i(13850);function r(e,t,i){return(0,n.eP)({debugName:()=>`Configuration Key "${e}"`},(t=>i.onDidChangeConfiguration((i=>{i.affectsConfiguration(e)&&t(i)}))),(()=>i.getValue(e)??t))}function o(e,t,i){const n=e.bindTo(t);return(0,s.zL)({debugName:()=>`Set Context Key "${e.key}"`},(e=>{n.set(i(e))}))}},49099:(e,t,i)=>{"use strict";i.d(t,{C:()=>s,e:()=>n});const s=(0,i(63591).u1)("openerService");function n(e){let t;const i=/^L?(\d+)(?:,(\d+))?(-L?(\d+)(?:,(\d+))?)?/.exec(e.fragment);return i&&(t={startLineNumber:parseInt(i[1]),startColumn:i[2]?parseInt(i[2]):1,endLineNumber:i[4]?parseInt(i[4]):void 0,endColumn:i[4]?i[5]?parseInt(i[5]):1:void 0},e=e.with({fragment:""})),{selection:t,uri:e}}},73823:(e,t,i)=>{"use strict";i.d(t,{G5:()=>n,N8:()=>o,ke:()=>r});var s=i(63591);const n=(0,s.u1)("progressService");Object.freeze({total(){},worked(){},done(){}});class r{static{this.None=Object.freeze({report(){}})}constructor(e){this.callback=e}report(e){this._value=e,this.callback(this._value)}}const o=(0,s.u1)("editorProgressService")},71597:(e,t,i)=>{"use strict";i.d(t,{Fd:()=>a,aJ:()=>s});var s,n=i(25890),r=i(5662),o=i(46359);!function(e){e[e.PRESERVE=0]="PRESERVE",e[e.LAST=1]="LAST"}(s||(s={}));const a={Quickaccess:"workbench.contributions.quickaccess"};o.O.add(a.Quickaccess,new class{constructor(){this.providers=[],this.defaultProvider=void 0}registerQuickAccessProvider(e){return 0===e.prefix.length?this.defaultProvider=e:this.providers.push(e),this.providers.sort(((e,t)=>t.prefix.length-e.prefix.length)),(0,r.s)((()=>{this.providers.splice(this.providers.indexOf(e),1),this.defaultProvider===e&&(this.defaultProvider=void 0)}))}getQuickAccessProviders(){return(0,n.Yc)([this.defaultProvider,...this.providers])}getQuickAccessProvider(e){return e&&this.providers.find((t=>e.startsWith(t.prefix)))||void 0||this.defaultProvider}})},51467:(e,t,i)=>{"use strict";i.d(t,{C1:()=>o,Fp:()=>a,GK:()=>c,Ym:()=>n,dH:()=>l,kF:()=>r});var s=i(63591);const n={ctrlCmd:!1,alt:!1};var r,o,a,l;!function(e){e[e.Blur=1]="Blur",e[e.Gesture=2]="Gesture",e[e.Other=3]="Other"}(r||(r={})),function(e){e[e.NONE=0]="NONE",e[e.FIRST=1]="FIRST",e[e.SECOND=2]="SECOND",e[e.LAST=3]="LAST"}(o||(o={})),function(e){e[e.First=1]="First",e[e.Second=2]="Second",e[e.Last=3]="Last",e[e.Next=4]="Next",e[e.Previous=5]="Previous",e[e.NextPage=6]="NextPage",e[e.PreviousPage=7]="PreviousPage",e[e.NextSeparator=8]="NextSeparator",e[e.PreviousSeparator=9]="PreviousSeparator"}(a||(a={})),function(e){e[e.Title=1]="Title",e[e.Inline=2]="Inline"}(l||(l={}));new class{constructor(e){this.options=e}};const c=(0,s.u1)("quickInputService")},46359:(e,t,i)=>{"use strict";i.d(t,{O:()=>r});var s=i(66782),n=i(631);const r=new class{constructor(){this.data=new Map}add(e,t){s.ok(n.Kg(e)),s.ok(n.Gv(t)),s.ok(!this.data.has(e),"There is already an extension with this id"),this.data.set(e,t)}as(e){return this.data.get(e)||null}}},9711:(e,t,i)=>{"use strict";i.d(t,{CS:()=>p,pc:()=>_,LP:()=>m});var s,n,r=i(41234),o=i(5662),a=i(631),l=i(90766),c=i(908);!function(e){e[e.STORAGE_DOES_NOT_EXIST=0]="STORAGE_DOES_NOT_EXIST",e[e.STORAGE_IN_MEMORY=1]="STORAGE_IN_MEMORY"}(s||(s={})),function(e){e[e.None=0]="None",e[e.Initialized=1]="Initialized",e[e.Closed=2]="Closed"}(n||(n={}));class h extends o.jG{static{this.DEFAULT_FLUSH_DELAY=100}constructor(e,t=Object.create(null)){super(),this.database=e,this.options=t,this._onDidChangeStorage=this._register(new r.fV),this.onDidChangeStorage=this._onDidChangeStorage.event,this.state=n.None,this.cache=new Map,this.flushDelayer=this._register(new l.Th(h.DEFAULT_FLUSH_DELAY)),this.pendingDeletes=new Set,this.pendingInserts=new Map,this.whenFlushedCallbacks=[],this.registerListeners()}registerListeners(){this._register(this.database.onDidChangeItemsExternal((e=>this.onDidChangeItemsExternal(e))))}onDidChangeItemsExternal(e){this._onDidChangeStorage.pause();try{e.changed?.forEach(((e,t)=>this.acceptExternal(t,e))),e.deleted?.forEach((e=>this.acceptExternal(e,void 0)))}finally{this._onDidChangeStorage.resume()}}acceptExternal(e,t){if(this.state===n.Closed)return;let i=!1;if((0,a.z)(t))i=this.cache.delete(e);else{this.cache.get(e)!==t&&(this.cache.set(e,t),i=!0)}i&&this._onDidChangeStorage.fire({key:e,external:!0})}get(e,t){const i=this.cache.get(e);return(0,a.z)(i)?t:i}getBoolean(e,t){const i=this.get(e);return(0,a.z)(i)?t:"true"===i}getNumber(e,t){const i=this.get(e);return(0,a.z)(i)?t:parseInt(i,10)}async set(e,t,i=!1){if(this.state===n.Closed)return;if((0,a.z)(t))return this.delete(e,i);const s=(0,a.Gv)(t)||Array.isArray(t)?(0,c.As)(t):String(t);return this.cache.get(e)!==s?(this.cache.set(e,s),this.pendingInserts.set(e,s),this.pendingDeletes.delete(e),this._onDidChangeStorage.fire({key:e,external:i}),this.doFlush()):void 0}async delete(e,t=!1){if(this.state===n.Closed)return;return this.cache.delete(e)?(this.pendingDeletes.has(e)||this.pendingDeletes.add(e),this.pendingInserts.delete(e),this._onDidChangeStorage.fire({key:e,external:t}),this.doFlush()):void 0}get hasPending(){return this.pendingInserts.size>0||this.pendingDeletes.size>0}async flushPending(){if(!this.hasPending)return;const e={insert:this.pendingInserts,delete:this.pendingDeletes};return this.pendingDeletes=new Set,this.pendingInserts=new Map,this.database.updateItems(e).finally((()=>{if(!this.hasPending)for(;this.whenFlushedCallbacks.length;)this.whenFlushedCallbacks.pop()?.()}))}async doFlush(e){return this.options.hint===s.STORAGE_IN_MEMORY?this.flushPending():this.flushDelayer.trigger((()=>this.flushPending()),e)}}class d{constructor(){this.onDidChangeItemsExternal=r.Jh.None,this.items=new Map}async updateItems(e){e.insert?.forEach(((e,t)=>this.items.set(t,e))),e.delete?.forEach((e=>this.items.delete(e)))}}var u=i(63591);const g="__$__targetStorageMarker",p=(0,u.u1)("storageService");var m;!function(e){e[e.NONE=0]="NONE",e[e.SHUTDOWN=1]="SHUTDOWN"}(m||(m={}));class f extends o.jG{static{this.DEFAULT_FLUSH_INTERVAL=6e4}constructor(e={flushInterval:f.DEFAULT_FLUSH_INTERVAL}){super(),this.options=e,this._onDidChangeValue=this._register(new r.fV),this._onDidChangeTarget=this._register(new r.fV),this._onWillSaveState=this._register(new r.vl),this.onWillSaveState=this._onWillSaveState.event,this._workspaceKeyTargets=void 0,this._profileKeyTargets=void 0,this._applicationKeyTargets=void 0}onDidChangeValue(e,t,i){return r.Jh.filter(this._onDidChangeValue.event,(i=>i.scope===e&&(void 0===t||i.key===t)),i)}emitDidChangeValue(e,t){const{key:i,external:s}=t;if(i===g){switch(e){case-1:this._applicationKeyTargets=void 0;break;case 0:this._profileKeyTargets=void 0;break;case 1:this._workspaceKeyTargets=void 0}this._onDidChangeTarget.fire({scope:e})}else this._onDidChangeValue.fire({scope:e,key:i,target:this.getKeyTargets(e)[i],external:s})}get(e,t,i){return this.getStorage(t)?.get(e,i)}getBoolean(e,t,i){return this.getStorage(t)?.getBoolean(e,i)}getNumber(e,t,i){return this.getStorage(t)?.getNumber(e,i)}store(e,t,i,s,n=!1){(0,a.z)(t)?this.remove(e,i,n):this.withPausedEmitters((()=>{this.updateKeyTarget(e,i,s),this.getStorage(i)?.set(e,t,n)}))}remove(e,t,i=!1){this.withPausedEmitters((()=>{this.updateKeyTarget(e,t,void 0),this.getStorage(t)?.delete(e,i)}))}withPausedEmitters(e){this._onDidChangeValue.pause(),this._onDidChangeTarget.pause();try{e()}finally{this._onDidChangeValue.resume(),this._onDidChangeTarget.resume()}}updateKeyTarget(e,t,i,s=!1){const n=this.getKeyTargets(t);"number"===typeof i?n[e]!==i&&(n[e]=i,this.getStorage(t)?.set(g,JSON.stringify(n),s)):"number"===typeof n[e]&&(delete n[e],this.getStorage(t)?.set(g,JSON.stringify(n),s))}get workspaceKeyTargets(){return this._workspaceKeyTargets||(this._workspaceKeyTargets=this.loadKeyTargets(1)),this._workspaceKeyTargets}get profileKeyTargets(){return this._profileKeyTargets||(this._profileKeyTargets=this.loadKeyTargets(0)),this._profileKeyTargets}get applicationKeyTargets(){return this._applicationKeyTargets||(this._applicationKeyTargets=this.loadKeyTargets(-1)),this._applicationKeyTargets}getKeyTargets(e){switch(e){case-1:return this.applicationKeyTargets;case 0:return this.profileKeyTargets;default:return this.workspaceKeyTargets}}loadKeyTargets(e){const t=this.getStorage(e);return t?function(e){const t=e.get(g);if(t)try{return JSON.parse(t)}catch(i){}return Object.create(null)}(t):Object.create(null)}}class _ extends f{constructor(){super(),this.applicationStorage=this._register(new h(new d,{hint:s.STORAGE_IN_MEMORY})),this.profileStorage=this._register(new h(new d,{hint:s.STORAGE_IN_MEMORY})),this.workspaceStorage=this._register(new h(new d,{hint:s.STORAGE_IN_MEMORY})),this._register(this.workspaceStorage.onDidChangeStorage((e=>this.emitDidChangeValue(1,e)))),this._register(this.profileStorage.onDidChangeStorage((e=>this.emitDidChangeValue(0,e)))),this._register(this.applicationStorage.onDidChangeStorage((e=>this.emitDidChangeValue(-1,e))))}getStorage(e){switch(e){case-1:return this.applicationStorage;case 0:return this.profileStorage;default:return this.workspaceStorage}}}},90651:(e,t,i)=>{"use strict";i.d(t,{k:()=>s});const s=(0,i(63591).u1)("telemetryService")},19070:(e,t,i)=>{"use strict";i.d(t,{Dk:()=>h,IN:()=>u,RE:()=>p,XS:()=>m,cv:()=>o,ho:()=>c,ir:()=>r,m$:()=>d,mk:()=>l,oJ:()=>a,t8:()=>g});var s=i(66261),n=i(47661);const r={keybindingLabelBackground:(0,s.GuP)(s.HDX),keybindingLabelForeground:(0,s.GuP)(s.eUu),keybindingLabelBorder:(0,s.GuP)(s.zUX),keybindingLabelBottomBorder:(0,s.GuP)(s.Qfh),keybindingLabelShadow:(0,s.GuP)(s.f9l)},o={buttonForeground:(0,s.GuP)(s.G_h),buttonSeparator:(0,s.GuP)(s.Q1$),buttonBackground:(0,s.GuP)(s.XJc),buttonHoverBackground:(0,s.GuP)(s.T9h),buttonSecondaryForeground:(0,s.GuP)(s.Inn),buttonSecondaryBackground:(0,s.GuP)(s.xOA),buttonSecondaryHoverBackground:(0,s.GuP)(s.nZG),buttonBorder:(0,s.GuP)(s.raQ)},a={progressBarBackground:(0,s.GuP)(s.BTi)},l={inputActiveOptionBorder:(0,s.GuP)(s.uNK),inputActiveOptionForeground:(0,s.GuP)(s.$$0),inputActiveOptionBackground:(0,s.GuP)(s.c1f)},c=((0,s.GuP)(s.jOE),(0,s.GuP)(s.Ukx),(0,s.GuP)(s.Ips),(0,s.GuP)(s.kPT),(0,s.GuP)(s.xWN),(0,s.GuP)(s.ZBU),(0,s.GuP)(s.jr9),(0,s.GuP)(s.OcU),(0,s.GuP)(s.C5U),(0,s.GuP)(s.t0B),(0,s.GuP)(s.CgL),(0,s.GuP)(s.FiB),(0,s.GuP)(s.f9l),(0,s.GuP)(s.b1q),(0,s.GuP)(s.tYX),(0,s.GuP)(s.JPj),(0,s.GuP)(s.bNw),(0,s.GuP)(s.vwp),{inputBackground:(0,s.GuP)(s.L4c),inputForeground:(0,s.GuP)(s.cws),inputBorder:(0,s.GuP)(s.Zgs),inputValidationInfoBorder:(0,s.GuP)(s.YSW),inputValidationInfoBackground:(0,s.GuP)(s.I$A),inputValidationInfoForeground:(0,s.GuP)(s.L9Z),inputValidationWarningBorder:(0,s.GuP)(s.C1n),inputValidationWarningBackground:(0,s.GuP)(s.ULt),inputValidationWarningForeground:(0,s.GuP)(s.T5N),inputValidationErrorBorder:(0,s.GuP)(s.eYZ),inputValidationErrorBackground:(0,s.GuP)(s._$n),inputValidationErrorForeground:(0,s.GuP)(s.h9z)}),h={listFilterWidgetBackground:(0,s.GuP)(s.pnl),listFilterWidgetOutline:(0,s.GuP)(s.fiM),listFilterWidgetNoMatchesOutline:(0,s.GuP)(s.P9Z),listFilterWidgetShadow:(0,s.GuP)(s.H8q),inputBoxStyles:c,toggleStyles:l},d={badgeBackground:(0,s.GuP)(s.WMx),badgeForeground:(0,s.GuP)(s.zRE),badgeBorder:(0,s.GuP)(s.b1q)},u=((0,s.GuP)(s.vV$),(0,s.GuP)(s.mc0),(0,s.GuP)(s.etE),(0,s.GuP)(s.etE),(0,s.GuP)(s.sAS),{listBackground:void 0,listInactiveFocusForeground:void 0,listFocusBackground:(0,s.GuP)(s.VFX),listFocusForeground:(0,s.GuP)(s.efJ),listFocusOutline:(0,s.GuP)(s.p7Y),listActiveSelectionBackground:(0,s.GuP)(s.Rjz),listActiveSelectionForeground:(0,s.GuP)(s.GVV),listActiveSelectionIconForeground:(0,s.GuP)(s.fED),listFocusAndSelectionOutline:(0,s.GuP)(s.gtq),listFocusAndSelectionBackground:(0,s.GuP)(s.Rjz),listFocusAndSelectionForeground:(0,s.GuP)(s.GVV),listInactiveSelectionBackground:(0,s.GuP)(s.uNx),listInactiveSelectionIconForeground:(0,s.GuP)(s.C9U),listInactiveSelectionForeground:(0,s.GuP)(s.f4y),listInactiveFocusBackground:(0,s.GuP)(s.CQ3),listInactiveFocusOutline:(0,s.GuP)(s.ijf),listHoverBackground:(0,s.GuP)(s.lO1),listHoverForeground:(0,s.GuP)(s.QRv),listDropOverBackground:(0,s.GuP)(s.Yoe),listDropBetweenBackground:(0,s.GuP)(s.yIp),listSelectionOutline:(0,s.GuP)(s.buw),listHoverOutline:(0,s.GuP)(s.buw),treeIndentGuidesStroke:(0,s.GuP)(s.U4U),treeInactiveIndentGuidesStroke:(0,s.GuP)(s.pft),treeStickyScrollBackground:void 0,treeStickyScrollBorder:void 0,treeStickyScrollShadow:(0,s.GuP)(s.bXl),tableColumnsBorder:(0,s.GuP)(s.k5u),tableOddRowsBackgroundColor:(0,s.GuP)(s.sbQ)});function g(e){return function(e,t){const i={...t};for(const n in e){const t=e[n];i[n]=void 0!==t?(0,s.GuP)(t):void 0}return i}(e,u)}const p={selectBackground:(0,s.GuP)(s.rvE),selectListBackground:(0,s.GuP)(s.lWP),selectForeground:(0,s.GuP)(s.yqq),decoratorRightForeground:(0,s.GuP)(s.NBf),selectBorder:(0,s.GuP)(s.HcB),focusBorder:(0,s.GuP)(s.tAP),listFocusBackground:(0,s.GuP)(s.AlL),listInactiveSelectionIconForeground:(0,s.GuP)(s.c7i),listFocusForeground:(0,s.GuP)(s.nH),listFocusOutline:(0,s.HP_)(s.buw,n.Q1.transparent.toString()),listHoverBackground:(0,s.GuP)(s.lO1),listHoverForeground:(0,s.GuP)(s.QRv),listHoverOutline:(0,s.GuP)(s.buw),selectListBorder:(0,s.GuP)(s.sIe),listBackground:void 0,listActiveSelectionBackground:void 0,listActiveSelectionForeground:void 0,listActiveSelectionIconForeground:void 0,listFocusAndSelectionBackground:void 0,listDropOverBackground:void 0,listDropBetweenBackground:void 0,listInactiveSelectionBackground:void 0,listInactiveSelectionForeground:void 0,listInactiveFocusBackground:void 0,listInactiveFocusOutline:void 0,listSelectionOutline:void 0,listFocusAndSelectionForeground:void 0,listFocusAndSelectionOutline:void 0,listInactiveFocusForeground:void 0,tableColumnsBorder:void 0,tableOddRowsBackgroundColor:void 0,treeIndentGuidesStroke:void 0,treeInactiveIndentGuidesStroke:void 0,treeStickyScrollBackground:void 0,treeStickyScrollBorder:void 0,treeStickyScrollShadow:void 0},m={shadowColor:(0,s.GuP)(s.f9l),borderColor:(0,s.GuP)(s.g$2),foregroundColor:(0,s.GuP)(s.dd_),backgroundColor:(0,s.GuP)(s.c6Y),selectionForegroundColor:(0,s.GuP)(s.pmr),selectionBackgroundColor:(0,s.GuP)(s.Ux$),selectionBorderColor:(0,s.GuP)(s.SNb),separatorColor:(0,s.GuP)(s.D7X),scrollbarShadow:(0,s.GuP)(s.bXl),scrollbarSliderBackground:(0,s.GuP)(s.gnV),scrollbarSliderHoverBackground:(0,s.GuP)(s.cI_),scrollbarSliderActiveBackground:(0,s.GuP)(s.mhZ)}},66261:(e,t,i)=>{"use strict";i.d(t,{FdG:()=>s.Fd,buw:()=>h,GuP:()=>s.Gu,Bbc:()=>s.Bb,HP_:()=>s.HP,WMx:()=>u,zRE:()=>g,sAS:()=>ce,vV$:()=>ae,etE:()=>le,mc0:()=>oe,XJc:()=>Ze,raQ:()=>et,G_h:()=>Qe,T9h:()=>Je,xOA:()=>it,Inn:()=>tt,nZG:()=>st,Q1$:()=>Xe,OcU:()=>dt,C5U:()=>gt,t0B:()=>ut,b1q:()=>c,EY1:()=>X,ZEf:()=>Z,Gj6:()=>J,ld8:()=>te,$BZ:()=>ie,GNm:()=>ee,Ztu:()=>I,YtV:()=>C,AN$:()=>L,Rbi:()=>w,f3U:()=>F,Ubg:()=>U,ECk:()=>B,p8Y:()=>H,S5J:()=>W,By2:()=>b,i61:()=>N,WfR:()=>V,oZ8:()=>z,tan:()=>M,IIb:()=>A,pOz:()=>k,WL6:()=>j,P6i:()=>G,B2L:()=>$,sjA:()=>q,_pU:()=>Y,HwT:()=>K,seu:()=>O,rm4:()=>D,QwA:()=>P,whs:()=>R,Stt:()=>x,Hng:()=>T,CgL:()=>E,sIe:()=>y,FiB:()=>S,tAP:()=>l,CU6:()=>o,t4B:()=>a,c1f:()=>Me,uNK:()=>Oe,$$0:()=>Pe,L4c:()=>Ae,Zgs:()=>Ie,cws:()=>Ne,_$n:()=>ze,eYZ:()=>je,h9z:()=>Ge,I$A:()=>Fe,YSW:()=>He,L9Z:()=>Ue,ULt:()=>Be,C1n:()=>Ve,T5N:()=>We,HDX:()=>pt,zUX:()=>ft,Qfh:()=>_t,eUu:()=>mt,Rjz:()=>St,GVV:()=>yt,fED:()=>wt,yIp:()=>Ot,Yoe:()=>It,pnl:()=>Pt,P9Z:()=>Ut,fiM:()=>Ft,H8q:()=>Ht,gtq:()=>Et,VFX:()=>vt,efJ:()=>Ct,eMz:()=>Mt,p7Y:()=>bt,QI5:()=>Dt,lO1:()=>At,QRv:()=>Nt,CQ3:()=>xt,ijf:()=>kt,uNx:()=>Lt,f4y:()=>Rt,C9U:()=>Tt,c6Y:()=>Kt,g$2:()=>Gt,dd_:()=>jt,Ux$:()=>qt,SNb:()=>$t,pmr:()=>Yt,D7X:()=>Qt,ILr:()=>xe,yLC:()=>Te,AjU:()=>Se,K1Z:()=>ke,KoI:()=>Le,yr0:()=>we,Xp1:()=>ye,uMG:()=>Re,yLr:()=>s.yL,fAP:()=>_e,z5H:()=>ve,iwL:()=>ti,NBf:()=>ei,tYX:()=>Ce,bNw:()=>Ee,JPj:()=>be,BTi:()=>v,ELA:()=>Xt,HJZ:()=>Zt,AlL:()=>ri,nH:()=>si,c7i:()=>ni,er1:()=>Jt,Ukx:()=>rt,Ips:()=>ot,jOE:()=>nt,xWN:()=>lt,ZBU:()=>ct,kPT:()=>at,jr9:()=>ht,x1A:()=>s.x1,bXl:()=>p,mhZ:()=>_,gnV:()=>m,cI_:()=>f,rvE:()=>Ke,HcB:()=>$e,yqq:()=>qe,lWP:()=>Ye,k5u:()=>Vt,sbQ:()=>zt,vwp:()=>d,JO0:()=>s.JO,pft:()=>Wt,U4U:()=>Bt,DSL:()=>ne,f9l:()=>se});var s=i(83844),n=i(78209),r=i(47661);const o=(0,s.x1)("foreground",{dark:"#CCCCCC",light:"#616161",hcDark:"#FFFFFF",hcLight:"#292929"},n.kg("foreground","Overall foreground color. This color is only used if not overridden by a component.")),a=((0,s.x1)("disabledForeground",{dark:"#CCCCCC80",light:"#61616180",hcDark:"#A5A5A5",hcLight:"#7F7F7F"},n.kg("disabledForeground","Overall foreground for disabled elements. This color is only used if not overridden by a component.")),(0,s.x1)("errorForeground",{dark:"#F48771",light:"#A1260D",hcDark:"#F48771",hcLight:"#B5200D"},n.kg("errorForeground","Overall foreground color for error messages. This color is only used if not overridden by a component.")),(0,s.x1)("descriptionForeground",{light:"#717171",dark:(0,s.JO)(o,.7),hcDark:(0,s.JO)(o,.7),hcLight:(0,s.JO)(o,.7)},n.kg("descriptionForeground","Foreground color for description text providing additional information, for example for a label.")),(0,s.x1)("icon.foreground",{dark:"#C5C5C5",light:"#424242",hcDark:"#FFFFFF",hcLight:"#292929"},n.kg("iconForeground","The default color for icons in the workbench."))),l=(0,s.x1)("focusBorder",{dark:"#007FD4",light:"#0090F1",hcDark:"#F38518",hcLight:"#006BBD"},n.kg("focusBorder","Overall border color for focused elements. This color is only used if not overridden by a component.")),c=(0,s.x1)("contrastBorder",{light:null,dark:null,hcDark:"#6FC3DF",hcLight:"#0F4A85"},n.kg("contrastBorder","An extra border around elements to separate them from others for greater contrast.")),h=(0,s.x1)("contrastActiveBorder",{light:null,dark:null,hcDark:l,hcLight:l},n.kg("activeContrastBorder","An extra border around active elements to separate them from others for greater contrast.")),d=((0,s.x1)("selection.background",null,n.kg("selectionBackground","The background color of text selections in the workbench (e.g. for input fields or text areas). Note that this does not apply to selections within the editor.")),(0,s.x1)("textLink.foreground",{light:"#006AB1",dark:"#3794FF",hcDark:"#21A6FF",hcLight:"#0F4A85"},n.kg("textLinkForeground","Foreground color for links in text."))),u=((0,s.x1)("textLink.activeForeground",{light:"#006AB1",dark:"#3794FF",hcDark:"#21A6FF",hcLight:"#0F4A85"},n.kg("textLinkActiveForeground","Foreground color for links in text when clicked on and on mouse hover.")),(0,s.x1)("textSeparator.foreground",{light:"#0000002e",dark:"#ffffff2e",hcDark:r.Q1.black,hcLight:"#292929"},n.kg("textSeparatorForeground","Color for text separators.")),(0,s.x1)("textPreformat.foreground",{light:"#A31515",dark:"#D7BA7D",hcDark:"#000000",hcLight:"#FFFFFF"},n.kg("textPreformatForeground","Foreground color for preformatted text segments.")),(0,s.x1)("textPreformat.background",{light:"#0000001A",dark:"#FFFFFF1A",hcDark:"#FFFFFF",hcLight:"#09345f"},n.kg("textPreformatBackground","Background color for preformatted text segments.")),(0,s.x1)("textBlockQuote.background",{light:"#f2f2f2",dark:"#222222",hcDark:null,hcLight:"#F2F2F2"},n.kg("textBlockQuoteBackground","Background color for block quotes in text.")),(0,s.x1)("textBlockQuote.border",{light:"#007acc80",dark:"#007acc80",hcDark:r.Q1.white,hcLight:"#292929"},n.kg("textBlockQuoteBorder","Border color for block quotes in text.")),(0,s.x1)("textCodeBlock.background",{light:"#dcdcdc66",dark:"#0a0a0a66",hcDark:r.Q1.black,hcLight:"#F2F2F2"},n.kg("textCodeBlockBackground","Background color for code blocks in text.")),(0,s.x1)("sash.hoverBorder",l,n.kg("sashActiveBorder","Border color of active sashes.")),(0,s.x1)("badge.background",{dark:"#4D4D4D",light:"#C4C4C4",hcDark:r.Q1.black,hcLight:"#0F4A85"},n.kg("badgeBackground","Badge background color. Badges are small information labels, e.g. for search results count."))),g=(0,s.x1)("badge.foreground",{dark:r.Q1.white,light:"#333",hcDark:r.Q1.white,hcLight:r.Q1.white},n.kg("badgeForeground","Badge foreground color. Badges are small information labels, e.g. for search results count.")),p=(0,s.x1)("scrollbar.shadow",{dark:"#000000",light:"#DDDDDD",hcDark:null,hcLight:null},n.kg("scrollbarShadow","Scrollbar shadow to indicate that the view is scrolled.")),m=(0,s.x1)("scrollbarSlider.background",{dark:r.Q1.fromHex("#797979").transparent(.4),light:r.Q1.fromHex("#646464").transparent(.4),hcDark:(0,s.JO)(c,.6),hcLight:(0,s.JO)(c,.4)},n.kg("scrollbarSliderBackground","Scrollbar slider background color.")),f=(0,s.x1)("scrollbarSlider.hoverBackground",{dark:r.Q1.fromHex("#646464").transparent(.7),light:r.Q1.fromHex("#646464").transparent(.7),hcDark:(0,s.JO)(c,.8),hcLight:(0,s.JO)(c,.8)},n.kg("scrollbarSliderHoverBackground","Scrollbar slider background color when hovering.")),_=(0,s.x1)("scrollbarSlider.activeBackground",{dark:r.Q1.fromHex("#BFBFBF").transparent(.4),light:r.Q1.fromHex("#000000").transparent(.6),hcDark:c,hcLight:c},n.kg("scrollbarSliderActiveBackground","Scrollbar slider background color when clicked on.")),v=(0,s.x1)("progressBar.background",{dark:r.Q1.fromHex("#0E70C0"),light:r.Q1.fromHex("#0E70C0"),hcDark:c,hcLight:c},n.kg("progressBarBackground","Background color of the progress bar that can show for long running operations.")),C=(0,s.x1)("editor.background",{light:"#ffffff",dark:"#1E1E1E",hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("editorBackground","Editor background color.")),b=(0,s.x1)("editor.foreground",{light:"#333333",dark:"#BBBBBB",hcDark:r.Q1.white,hcLight:o},n.kg("editorForeground","Editor default foreground color.")),E=((0,s.x1)("editorStickyScroll.background",C,n.kg("editorStickyScrollBackground","Background color of sticky scroll in the editor")),(0,s.x1)("editorStickyScrollHover.background",{dark:"#2A2D2E",light:"#F0F0F0",hcDark:null,hcLight:r.Q1.fromHex("#0F4A85").transparent(.1)},n.kg("editorStickyScrollHoverBackground","Background color of sticky scroll on hover in the editor")),(0,s.x1)("editorStickyScroll.border",{dark:null,light:null,hcDark:c,hcLight:c},n.kg("editorStickyScrollBorder","Border color of sticky scroll in the editor")),(0,s.x1)("editorStickyScroll.shadow",p,n.kg("editorStickyScrollShadow"," Shadow color of sticky scroll in the editor")),(0,s.x1)("editorWidget.background",{dark:"#252526",light:"#F3F3F3",hcDark:"#0C141F",hcLight:r.Q1.white},n.kg("editorWidgetBackground","Background color of editor widgets, such as find/replace."))),S=(0,s.x1)("editorWidget.foreground",o,n.kg("editorWidgetForeground","Foreground color of editor widgets, such as find/replace.")),y=(0,s.x1)("editorWidget.border",{dark:"#454545",light:"#C8C8C8",hcDark:c,hcLight:c},n.kg("editorWidgetBorder","Border color of editor widgets. The color is only used if the widget chooses to have a border and if the color is not overridden by a widget.")),w=((0,s.x1)("editorWidget.resizeBorder",null,n.kg("editorWidgetResizeBorder","Border color of the resize bar of editor widgets. The color is only used if the widget chooses to have a resize border and if the color is not overridden by a widget.")),(0,s.x1)("editorError.background",null,n.kg("editorError.background","Background color of error text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("editorError.foreground",{dark:"#F14C4C",light:"#E51400",hcDark:"#F48771",hcLight:"#B5200D"},n.kg("editorError.foreground","Foreground color of error squigglies in the editor."))),L=(0,s.x1)("editorError.border",{dark:null,light:null,hcDark:r.Q1.fromHex("#E47777").transparent(.8),hcLight:"#B5200D"},n.kg("errorBorder","If set, color of double underlines for errors in the editor.")),R=(0,s.x1)("editorWarning.background",null,n.kg("editorWarning.background","Background color of warning text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),T=(0,s.x1)("editorWarning.foreground",{dark:"#CCA700",light:"#BF8803",hcDark:"#FFD370",hcLight:"#895503"},n.kg("editorWarning.foreground","Foreground color of warning squigglies in the editor.")),x=(0,s.x1)("editorWarning.border",{dark:null,light:null,hcDark:r.Q1.fromHex("#FFCC00").transparent(.8),hcLight:r.Q1.fromHex("#FFCC00").transparent(.8)},n.kg("warningBorder","If set, color of double underlines for warnings in the editor.")),k=((0,s.x1)("editorInfo.background",null,n.kg("editorInfo.background","Background color of info text in the editor. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("editorInfo.foreground",{dark:"#3794FF",light:"#1a85ff",hcDark:"#3794FF",hcLight:"#1a85ff"},n.kg("editorInfo.foreground","Foreground color of info squigglies in the editor."))),A=(0,s.x1)("editorInfo.border",{dark:null,light:null,hcDark:r.Q1.fromHex("#3794FF").transparent(.8),hcLight:"#292929"},n.kg("infoBorder","If set, color of double underlines for infos in the editor.")),N=(0,s.x1)("editorHint.foreground",{dark:r.Q1.fromHex("#eeeeee").transparent(.7),light:"#6c6c6c",hcDark:null,hcLight:null},n.kg("editorHint.foreground","Foreground color of hint squigglies in the editor.")),I=((0,s.x1)("editorHint.border",{dark:null,light:null,hcDark:r.Q1.fromHex("#eeeeee").transparent(.8),hcLight:"#292929"},n.kg("hintBorder","If set, color of double underlines for hints in the editor.")),(0,s.x1)("editorLink.activeForeground",{dark:"#4E94CE",light:r.Q1.blue,hcDark:r.Q1.cyan,hcLight:"#292929"},n.kg("activeLinkForeground","Color of active links."))),O=(0,s.x1)("editor.selectionBackground",{light:"#ADD6FF",dark:"#264F78",hcDark:"#f3f518",hcLight:"#0F4A85"},n.kg("editorSelectionBackground","Color of the editor selection.")),D=(0,s.x1)("editor.selectionForeground",{light:null,dark:null,hcDark:"#000000",hcLight:r.Q1.white},n.kg("editorSelectionForeground","Color of the selected text for high contrast.")),M=(0,s.x1)("editor.inactiveSelectionBackground",{light:(0,s.JO)(O,.5),dark:(0,s.JO)(O,.5),hcDark:(0,s.JO)(O,.7),hcLight:(0,s.JO)(O,.5)},n.kg("editorInactiveSelection","Color of the selection in an inactive editor. The color must not be opaque so as not to hide underlying decorations."),!0),P=(0,s.x1)("editor.selectionHighlightBackground",{light:(0,s.oG)(O,C,.3,.6),dark:(0,s.oG)(O,C,.3,.6),hcDark:null,hcLight:null},n.kg("editorSelectionHighlight","Color for regions with the same content as the selection. The color must not be opaque so as not to hide underlying decorations."),!0),F=((0,s.x1)("editor.selectionHighlightBorder",{light:null,dark:null,hcDark:h,hcLight:h},n.kg("editorSelectionHighlightBorder","Border color for regions with the same content as the selection.")),(0,s.x1)("editor.findMatchBackground",{light:"#A8AC94",dark:"#515C6A",hcDark:null,hcLight:null},n.kg("editorFindMatch","Color of the current search match.")),(0,s.x1)("editor.findMatchForeground",null,n.kg("editorFindMatchForeground","Text color of the current search match."))),U=(0,s.x1)("editor.findMatchHighlightBackground",{light:"#EA5C0055",dark:"#EA5C0055",hcDark:null,hcLight:null},n.kg("findMatchHighlight","Color of the other search matches. The color must not be opaque so as not to hide underlying decorations."),!0),H=(0,s.x1)("editor.findMatchHighlightForeground",null,n.kg("findMatchHighlightForeground","Foreground color of the other search matches."),!0),B=((0,s.x1)("editor.findRangeHighlightBackground",{dark:"#3a3d4166",light:"#b4b4b44d",hcDark:null,hcLight:null},n.kg("findRangeHighlight","Color of the range limiting the search. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("editor.findMatchBorder",{light:null,dark:null,hcDark:h,hcLight:h},n.kg("editorFindMatchBorder","Border color of the current search match.")),(0,s.x1)("editor.findMatchHighlightBorder",{light:null,dark:null,hcDark:h,hcLight:h},n.kg("findMatchHighlightBorder","Border color of the other search matches."))),W=(0,s.x1)("editor.findRangeHighlightBorder",{dark:null,light:null,hcDark:(0,s.JO)(h,.4),hcLight:(0,s.JO)(h,.4)},n.kg("findRangeHighlightBorder","Border color of the range limiting the search. The color must not be opaque so as not to hide underlying decorations."),!0),V=((0,s.x1)("editor.hoverHighlightBackground",{light:"#ADD6FF26",dark:"#264f7840",hcDark:"#ADD6FF26",hcLight:null},n.kg("hoverHighlight","Highlight below the word for which a hover is shown. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("editorHoverWidget.background",E,n.kg("hoverBackground","Background color of the editor hover."))),z=((0,s.x1)("editorHoverWidget.foreground",S,n.kg("hoverForeground","Foreground color of the editor hover.")),(0,s.x1)("editorHoverWidget.border",y,n.kg("hoverBorder","Border color of the editor hover."))),G=((0,s.x1)("editorHoverWidget.statusBarBackground",{dark:(0,s.a)(V,.2),light:(0,s.e$)(V,.05),hcDark:E,hcLight:E},n.kg("statusBarBackground","Background color of the editor hover status bar.")),(0,s.x1)("editorInlayHint.foreground",{dark:"#969696",light:"#969696",hcDark:r.Q1.white,hcLight:r.Q1.black},n.kg("editorInlayHintForeground","Foreground color of inline hints"))),j=(0,s.x1)("editorInlayHint.background",{dark:(0,s.JO)(u,.1),light:(0,s.JO)(u,.1),hcDark:(0,s.JO)(r.Q1.white,.1),hcLight:(0,s.JO)(u,.1)},n.kg("editorInlayHintBackground","Background color of inline hints")),K=(0,s.x1)("editorInlayHint.typeForeground",G,n.kg("editorInlayHintForegroundTypes","Foreground color of inline hints for types")),Y=(0,s.x1)("editorInlayHint.typeBackground",j,n.kg("editorInlayHintBackgroundTypes","Background color of inline hints for types")),q=(0,s.x1)("editorInlayHint.parameterForeground",G,n.kg("editorInlayHintForegroundParameter","Foreground color of inline hints for parameters")),$=(0,s.x1)("editorInlayHint.parameterBackground",j,n.kg("editorInlayHintBackgroundParameter","Background color of inline hints for parameters")),Q=(0,s.x1)("editorLightBulb.foreground",{dark:"#FFCC00",light:"#DDB100",hcDark:"#FFCC00",hcLight:"#007ACC"},n.kg("editorLightBulbForeground","The color used for the lightbulb actions icon.")),X=((0,s.x1)("editorLightBulbAutoFix.foreground",{dark:"#75BEFF",light:"#007ACC",hcDark:"#75BEFF",hcLight:"#007ACC"},n.kg("editorLightBulbAutoFixForeground","The color used for the lightbulb auto fix actions icon.")),(0,s.x1)("editorLightBulbAi.foreground",Q,n.kg("editorLightBulbAiForeground","The color used for the lightbulb AI icon.")),(0,s.x1)("editor.snippetTabstopHighlightBackground",{dark:new r.Q1(new r.bU(124,124,124,.3)),light:new r.Q1(new r.bU(10,50,100,.2)),hcDark:new r.Q1(new r.bU(124,124,124,.3)),hcLight:new r.Q1(new r.bU(10,50,100,.2))},n.kg("snippetTabstopHighlightBackground","Highlight background color of a snippet tabstop.")),(0,s.x1)("editor.snippetTabstopHighlightBorder",null,n.kg("snippetTabstopHighlightBorder","Highlight border color of a snippet tabstop.")),(0,s.x1)("editor.snippetFinalTabstopHighlightBackground",null,n.kg("snippetFinalTabstopHighlightBackground","Highlight background color of the final tabstop of a snippet.")),(0,s.x1)("editor.snippetFinalTabstopHighlightBorder",{dark:"#525252",light:new r.Q1(new r.bU(10,50,100,.5)),hcDark:"#525252",hcLight:"#292929"},n.kg("snippetFinalTabstopHighlightBorder","Highlight border color of the final tabstop of a snippet.")),new r.Q1(new r.bU(155,185,85,.2))),Z=new r.Q1(new r.bU(255,0,0,.2)),J=(0,s.x1)("diffEditor.insertedTextBackground",{dark:"#9ccc2c33",light:"#9ccc2c40",hcDark:null,hcLight:null},n.kg("diffEditorInserted","Background color for text that got inserted. The color must not be opaque so as not to hide underlying decorations."),!0),ee=(0,s.x1)("diffEditor.removedTextBackground",{dark:"#ff000033",light:"#ff000033",hcDark:null,hcLight:null},n.kg("diffEditorRemoved","Background color for text that got removed. The color must not be opaque so as not to hide underlying decorations."),!0),te=((0,s.x1)("diffEditor.insertedLineBackground",{dark:X,light:X,hcDark:null,hcLight:null},n.kg("diffEditorInsertedLines","Background color for lines that got inserted. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("diffEditor.removedLineBackground",{dark:Z,light:Z,hcDark:null,hcLight:null},n.kg("diffEditorRemovedLines","Background color for lines that got removed. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("diffEditorGutter.insertedLineBackground",null,n.kg("diffEditorInsertedLineGutter","Background color for the margin where lines got inserted.")),(0,s.x1)("diffEditorGutter.removedLineBackground",null,n.kg("diffEditorRemovedLineGutter","Background color for the margin where lines got removed.")),(0,s.x1)("diffEditorOverview.insertedForeground",null,n.kg("diffEditorOverviewInserted","Diff overview ruler foreground for inserted content."))),ie=(0,s.x1)("diffEditorOverview.removedForeground",null,n.kg("diffEditorOverviewRemoved","Diff overview ruler foreground for removed content.")),se=((0,s.x1)("diffEditor.insertedTextBorder",{dark:null,light:null,hcDark:"#33ff2eff",hcLight:"#374E06"},n.kg("diffEditorInsertedOutline","Outline color for the text that got inserted.")),(0,s.x1)("diffEditor.removedTextBorder",{dark:null,light:null,hcDark:"#FF008F",hcLight:"#AD0707"},n.kg("diffEditorRemovedOutline","Outline color for text that got removed.")),(0,s.x1)("diffEditor.border",{dark:null,light:null,hcDark:c,hcLight:c},n.kg("diffEditorBorder","Border color between the two text editors.")),(0,s.x1)("diffEditor.diagonalFill",{dark:"#cccccc33",light:"#22222233",hcDark:null,hcLight:null},n.kg("diffDiagonalFill","Color of the diff editor's diagonal fill. The diagonal fill is used in side-by-side diff views.")),(0,s.x1)("diffEditor.unchangedRegionBackground","sideBar.background",n.kg("diffEditor.unchangedRegionBackground","The background color of unchanged blocks in the diff editor.")),(0,s.x1)("diffEditor.unchangedRegionForeground","foreground",n.kg("diffEditor.unchangedRegionForeground","The foreground color of unchanged blocks in the diff editor.")),(0,s.x1)("diffEditor.unchangedCodeBackground",{dark:"#74747429",light:"#b8b8b829",hcDark:null,hcLight:null},n.kg("diffEditor.unchangedCodeBackground","The background color of unchanged code in the diff editor.")),(0,s.x1)("widget.shadow",{dark:(0,s.JO)(r.Q1.black,.36),light:(0,s.JO)(r.Q1.black,.16),hcDark:null,hcLight:null},n.kg("widgetShadow","Shadow color of widgets such as find/replace inside the editor."))),ne=(0,s.x1)("widget.border",{dark:null,light:null,hcDark:c,hcLight:c},n.kg("widgetBorder","Border color of widgets such as find/replace inside the editor.")),re=(0,s.x1)("toolbar.hoverBackground",{dark:"#5a5d5e50",light:"#b8b8b850",hcDark:null,hcLight:null},n.kg("toolbarHoverBackground","Toolbar background when hovering over actions using the mouse")),oe=((0,s.x1)("toolbar.hoverOutline",{dark:null,light:null,hcDark:h,hcLight:h},n.kg("toolbarHoverOutline","Toolbar outline when hovering over actions using the mouse")),(0,s.x1)("toolbar.activeBackground",{dark:(0,s.a)(re,.1),light:(0,s.e$)(re,.1),hcDark:null,hcLight:null},n.kg("toolbarActiveBackground","Toolbar background when holding the mouse over actions")),(0,s.x1)("breadcrumb.foreground",(0,s.JO)(o,.8),n.kg("breadcrumbsFocusForeground","Color of focused breadcrumb items."))),ae=(0,s.x1)("breadcrumb.background",C,n.kg("breadcrumbsBackground","Background color of breadcrumb items.")),le=(0,s.x1)("breadcrumb.focusForeground",{light:(0,s.e$)(o,.2),dark:(0,s.a)(o,.1),hcDark:(0,s.a)(o,.1),hcLight:(0,s.a)(o,.1)},n.kg("breadcrumbsFocusForeground","Color of focused breadcrumb items.")),ce=(0,s.x1)("breadcrumb.activeSelectionForeground",{light:(0,s.e$)(o,.2),dark:(0,s.a)(o,.1),hcDark:(0,s.a)(o,.1),hcLight:(0,s.a)(o,.1)},n.kg("breadcrumbsSelectedForeground","Color of selected breadcrumb items.")),he=((0,s.x1)("breadcrumbPicker.background",E,n.kg("breadcrumbsSelectedBackground","Background color of breadcrumb item picker.")),r.Q1.fromHex("#40C8AE").transparent(.5)),de=r.Q1.fromHex("#40A6FF").transparent(.5),ue=r.Q1.fromHex("#606060").transparent(.4),ge=(0,s.x1)("merge.currentHeaderBackground",{dark:he,light:he,hcDark:null,hcLight:null},n.kg("mergeCurrentHeaderBackground","Current header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),pe=((0,s.x1)("merge.currentContentBackground",(0,s.JO)(ge,.4),n.kg("mergeCurrentContentBackground","Current content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("merge.incomingHeaderBackground",{dark:de,light:de,hcDark:null,hcLight:null},n.kg("mergeIncomingHeaderBackground","Incoming header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0)),me=((0,s.x1)("merge.incomingContentBackground",(0,s.JO)(pe,.4),n.kg("mergeIncomingContentBackground","Incoming content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("merge.commonHeaderBackground",{dark:ue,light:ue,hcDark:null,hcLight:null},n.kg("mergeCommonHeaderBackground","Common ancestor header background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0)),fe=((0,s.x1)("merge.commonContentBackground",(0,s.JO)(me,.4),n.kg("mergeCommonContentBackground","Common ancestor content background in inline merge-conflicts. The color must not be opaque so as not to hide underlying decorations."),!0),(0,s.x1)("merge.border",{dark:null,light:null,hcDark:"#C3DF6F",hcLight:"#007ACC"},n.kg("mergeBorder","Border color on headers and the splitter in inline merge-conflicts."))),_e=((0,s.x1)("editorOverviewRuler.currentContentForeground",{dark:(0,s.JO)(ge,1),light:(0,s.JO)(ge,1),hcDark:fe,hcLight:fe},n.kg("overviewRulerCurrentContentForeground","Current overview ruler foreground for inline merge-conflicts.")),(0,s.x1)("editorOverviewRuler.incomingContentForeground",{dark:(0,s.JO)(pe,1),light:(0,s.JO)(pe,1),hcDark:fe,hcLight:fe},n.kg("overviewRulerIncomingContentForeground","Incoming overview ruler foreground for inline merge-conflicts.")),(0,s.x1)("editorOverviewRuler.commonContentForeground",{dark:(0,s.JO)(me,1),light:(0,s.JO)(me,1),hcDark:fe,hcLight:fe},n.kg("overviewRulerCommonContentForeground","Common ancestor overview ruler foreground for inline merge-conflicts.")),(0,s.x1)("editorOverviewRuler.findMatchForeground",{dark:"#d186167e",light:"#d186167e",hcDark:"#AB5A00",hcLight:"#AB5A00"},n.kg("overviewRulerFindMatchForeground","Overview ruler marker color for find matches. The color must not be opaque so as not to hide underlying decorations."),!0)),ve=(0,s.x1)("editorOverviewRuler.selectionHighlightForeground","#A0A0A0CC",n.kg("overviewRulerSelectionHighlightForeground","Overview ruler marker color for selection highlights. The color must not be opaque so as not to hide underlying decorations."),!0),Ce=(0,s.x1)("problemsErrorIcon.foreground",w,n.kg("problemsErrorIconForeground","The color used for the problems error icon.")),be=(0,s.x1)("problemsWarningIcon.foreground",T,n.kg("problemsWarningIconForeground","The color used for the problems warning icon.")),Ee=(0,s.x1)("problemsInfoIcon.foreground",k,n.kg("problemsInfoIconForeground","The color used for the problems info icon.")),Se=(0,s.x1)("minimap.findMatchHighlight",{light:"#d18616",dark:"#d18616",hcDark:"#AB5A00",hcLight:"#0F4A85"},n.kg("minimapFindMatchHighlight","Minimap marker color for find matches."),!0),ye=(0,s.x1)("minimap.selectionOccurrenceHighlight",{light:"#c9c9c9",dark:"#676767",hcDark:"#ffffff",hcLight:"#0F4A85"},n.kg("minimapSelectionOccurrenceHighlight","Minimap marker color for repeating editor selections."),!0),we=(0,s.x1)("minimap.selectionHighlight",{light:"#ADD6FF",dark:"#264F78",hcDark:"#ffffff",hcLight:"#0F4A85"},n.kg("minimapSelectionHighlight","Minimap marker color for the editor selection."),!0),Le=(0,s.x1)("minimap.infoHighlight",{dark:k,light:k,hcDark:A,hcLight:A},n.kg("minimapInfo","Minimap marker color for infos.")),Re=(0,s.x1)("minimap.warningHighlight",{dark:T,light:T,hcDark:x,hcLight:x},n.kg("overviewRuleWarning","Minimap marker color for warnings.")),Te=(0,s.x1)("minimap.errorHighlight",{dark:new r.Q1(new r.bU(255,18,18,.7)),light:new r.Q1(new r.bU(255,18,18,.7)),hcDark:new r.Q1(new r.bU(255,50,50,1)),hcLight:"#B5200D"},n.kg("minimapError","Minimap marker color for errors.")),xe=(0,s.x1)("minimap.background",null,n.kg("minimapBackground","Minimap background color.")),ke=(0,s.x1)("minimap.foregroundOpacity",r.Q1.fromHex("#000f"),n.kg("minimapForegroundOpacity",'Opacity of foreground elements rendered in the minimap. For example, "#000000c0" will render the elements with 75% opacity.')),Ae=((0,s.x1)("minimapSlider.background",(0,s.JO)(m,.5),n.kg("minimapSliderBackground","Minimap slider background color.")),(0,s.x1)("minimapSlider.hoverBackground",(0,s.JO)(f,.5),n.kg("minimapSliderHoverBackground","Minimap slider background color when hovering.")),(0,s.x1)("minimapSlider.activeBackground",(0,s.JO)(_,.5),n.kg("minimapSliderActiveBackground","Minimap slider background color when clicked on.")),(0,s.x1)("charts.foreground",o,n.kg("chartsForeground","The foreground color used in charts.")),(0,s.x1)("charts.lines",(0,s.JO)(o,.5),n.kg("chartsLines","The color used for horizontal lines in charts.")),(0,s.x1)("charts.red",w,n.kg("chartsRed","The red color used in chart visualizations.")),(0,s.x1)("charts.blue",k,n.kg("chartsBlue","The blue color used in chart visualizations.")),(0,s.x1)("charts.yellow",T,n.kg("chartsYellow","The yellow color used in chart visualizations.")),(0,s.x1)("charts.orange",Se,n.kg("chartsOrange","The orange color used in chart visualizations.")),(0,s.x1)("charts.green",{dark:"#89D185",light:"#388A34",hcDark:"#89D185",hcLight:"#374e06"},n.kg("chartsGreen","The green color used in chart visualizations.")),(0,s.x1)("charts.purple",{dark:"#B180D7",light:"#652D90",hcDark:"#B180D7",hcLight:"#652D90"},n.kg("chartsPurple","The purple color used in chart visualizations.")),(0,s.x1)("input.background",{dark:"#3C3C3C",light:r.Q1.white,hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("inputBoxBackground","Input box background."))),Ne=(0,s.x1)("input.foreground",o,n.kg("inputBoxForeground","Input box foreground.")),Ie=(0,s.x1)("input.border",{dark:null,light:null,hcDark:c,hcLight:c},n.kg("inputBoxBorder","Input box border.")),Oe=(0,s.x1)("inputOption.activeBorder",{dark:"#007ACC",light:"#007ACC",hcDark:c,hcLight:c},n.kg("inputBoxActiveOptionBorder","Border color of activated options in input fields.")),De=(0,s.x1)("inputOption.hoverBackground",{dark:"#5a5d5e80",light:"#b8b8b850",hcDark:null,hcLight:null},n.kg("inputOption.hoverBackground","Background color of activated options in input fields.")),Me=(0,s.x1)("inputOption.activeBackground",{dark:(0,s.JO)(l,.4),light:(0,s.JO)(l,.2),hcDark:r.Q1.transparent,hcLight:r.Q1.transparent},n.kg("inputOption.activeBackground","Background hover color of options in input fields.")),Pe=(0,s.x1)("inputOption.activeForeground",{dark:r.Q1.white,light:r.Q1.black,hcDark:o,hcLight:o},n.kg("inputOption.activeForeground","Foreground color of activated options in input fields.")),Fe=((0,s.x1)("input.placeholderForeground",{light:(0,s.JO)(o,.5),dark:(0,s.JO)(o,.5),hcDark:(0,s.JO)(o,.7),hcLight:(0,s.JO)(o,.7)},n.kg("inputPlaceholderForeground","Input box foreground color for placeholder text.")),(0,s.x1)("inputValidation.infoBackground",{dark:"#063B49",light:"#D6ECF2",hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("inputValidationInfoBackground","Input validation background color for information severity."))),Ue=(0,s.x1)("inputValidation.infoForeground",{dark:null,light:null,hcDark:null,hcLight:o},n.kg("inputValidationInfoForeground","Input validation foreground color for information severity.")),He=(0,s.x1)("inputValidation.infoBorder",{dark:"#007acc",light:"#007acc",hcDark:c,hcLight:c},n.kg("inputValidationInfoBorder","Input validation border color for information severity.")),Be=(0,s.x1)("inputValidation.warningBackground",{dark:"#352A05",light:"#F6F5D2",hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("inputValidationWarningBackground","Input validation background color for warning severity.")),We=(0,s.x1)("inputValidation.warningForeground",{dark:null,light:null,hcDark:null,hcLight:o},n.kg("inputValidationWarningForeground","Input validation foreground color for warning severity.")),Ve=(0,s.x1)("inputValidation.warningBorder",{dark:"#B89500",light:"#B89500",hcDark:c,hcLight:c},n.kg("inputValidationWarningBorder","Input validation border color for warning severity.")),ze=(0,s.x1)("inputValidation.errorBackground",{dark:"#5A1D1D",light:"#F2DEDE",hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("inputValidationErrorBackground","Input validation background color for error severity.")),Ge=(0,s.x1)("inputValidation.errorForeground",{dark:null,light:null,hcDark:null,hcLight:o},n.kg("inputValidationErrorForeground","Input validation foreground color for error severity.")),je=(0,s.x1)("inputValidation.errorBorder",{dark:"#BE1100",light:"#BE1100",hcDark:c,hcLight:c},n.kg("inputValidationErrorBorder","Input validation border color for error severity.")),Ke=(0,s.x1)("dropdown.background",{dark:"#3C3C3C",light:r.Q1.white,hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("dropdownBackground","Dropdown background.")),Ye=(0,s.x1)("dropdown.listBackground",{dark:null,light:null,hcDark:r.Q1.black,hcLight:r.Q1.white},n.kg("dropdownListBackground","Dropdown list background.")),qe=(0,s.x1)("dropdown.foreground",{dark:"#F0F0F0",light:o,hcDark:r.Q1.white,hcLight:o},n.kg("dropdownForeground","Dropdown foreground.")),$e=(0,s.x1)("dropdown.border",{dark:Ke,light:"#CECECE",hcDark:c,hcLight:c},n.kg("dropdownBorder","Dropdown border.")),Qe=(0,s.x1)("button.foreground",r.Q1.white,n.kg("buttonForeground","Button foreground color.")),Xe=(0,s.x1)("button.separator",(0,s.JO)(Qe,.4),n.kg("buttonSeparator","Button separator color.")),Ze=(0,s.x1)("button.background",{dark:"#0E639C",light:"#007ACC",hcDark:null,hcLight:"#0F4A85"},n.kg("buttonBackground","Button background color.")),Je=(0,s.x1)("button.hoverBackground",{dark:(0,s.a)(Ze,.2),light:(0,s.e$)(Ze,.2),hcDark:Ze,hcLight:Ze},n.kg("buttonHoverBackground","Button background color when hovering.")),et=(0,s.x1)("button.border",c,n.kg("buttonBorder","Button border color.")),tt=(0,s.x1)("button.secondaryForeground",{dark:r.Q1.white,light:r.Q1.white,hcDark:r.Q1.white,hcLight:o},n.kg("buttonSecondaryForeground","Secondary button foreground color.")),it=(0,s.x1)("button.secondaryBackground",{dark:"#3A3D41",light:"#5F6A79",hcDark:null,hcLight:r.Q1.white},n.kg("buttonSecondaryBackground","Secondary button background color.")),st=(0,s.x1)("button.secondaryHoverBackground",{dark:(0,s.a)(it,.2),light:(0,s.e$)(it,.2),hcDark:null,hcLight:null},n.kg("buttonSecondaryHoverBackground","Secondary button background color when hovering.")),nt=(0,s.x1)("radio.activeForeground",Pe,n.kg("radioActiveForeground","Foreground color of active radio option.")),rt=(0,s.x1)("radio.activeBackground",Me,n.kg("radioBackground","Background color of active radio option.")),ot=(0,s.x1)("radio.activeBorder",Oe,n.kg("radioActiveBorder","Border color of the active radio option.")),at=(0,s.x1)("radio.inactiveForeground",null,n.kg("radioInactiveForeground","Foreground color of inactive radio option.")),lt=(0,s.x1)("radio.inactiveBackground",null,n.kg("radioInactiveBackground","Background color of inactive radio option.")),ct=(0,s.x1)("radio.inactiveBorder",{light:(0,s.JO)(nt,.2),dark:(0,s.JO)(nt,.2),hcDark:(0,s.JO)(nt,.4),hcLight:(0,s.JO)(nt,.2)},n.kg("radioInactiveBorder","Border color of the inactive radio option.")),ht=(0,s.x1)("radio.inactiveHoverBackground",De,n.kg("radioHoverBackground","Background color of inactive active radio option when hovering.")),dt=(0,s.x1)("checkbox.background",Ke,n.kg("checkbox.background","Background color of checkbox widget.")),ut=((0,s.x1)("checkbox.selectBackground",E,n.kg("checkbox.select.background","Background color of checkbox widget when the element it's in is selected.")),(0,s.x1)("checkbox.foreground",qe,n.kg("checkbox.foreground","Foreground color of checkbox widget."))),gt=(0,s.x1)("checkbox.border",$e,n.kg("checkbox.border","Border color of checkbox widget.")),pt=((0,s.x1)("checkbox.selectBorder",a,n.kg("checkbox.select.border","Border color of checkbox widget when the element it's in is selected.")),(0,s.x1)("keybindingLabel.background",{dark:new r.Q1(new r.bU(128,128,128,.17)),light:new r.Q1(new r.bU(221,221,221,.4)),hcDark:r.Q1.transparent,hcLight:r.Q1.transparent},n.kg("keybindingLabelBackground","Keybinding label background color. The keybinding label is used to represent a keyboard shortcut."))),mt=(0,s.x1)("keybindingLabel.foreground",{dark:r.Q1.fromHex("#CCCCCC"),light:r.Q1.fromHex("#555555"),hcDark:r.Q1.white,hcLight:o},n.kg("keybindingLabelForeground","Keybinding label foreground color. The keybinding label is used to represent a keyboard shortcut.")),ft=(0,s.x1)("keybindingLabel.border",{dark:new r.Q1(new r.bU(51,51,51,.6)),light:new r.Q1(new r.bU(204,204,204,.4)),hcDark:new r.Q1(new r.bU(111,195,223)),hcLight:c},n.kg("keybindingLabelBorder","Keybinding label border color. The keybinding label is used to represent a keyboard shortcut.")),_t=(0,s.x1)("keybindingLabel.bottomBorder",{dark:new r.Q1(new r.bU(68,68,68,.6)),light:new r.Q1(new r.bU(187,187,187,.4)),hcDark:new r.Q1(new r.bU(111,195,223)),hcLight:o},n.kg("keybindingLabelBottomBorder","Keybinding label border bottom color. The keybinding label is used to represent a keyboard shortcut.")),vt=(0,s.x1)("list.focusBackground",null,n.kg("listFocusBackground","List/Tree background color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),Ct=(0,s.x1)("list.focusForeground",null,n.kg("listFocusForeground","List/Tree foreground color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),bt=(0,s.x1)("list.focusOutline",{dark:l,light:l,hcDark:h,hcLight:h},n.kg("listFocusOutline","List/Tree outline color for the focused item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),Et=(0,s.x1)("list.focusAndSelectionOutline",null,n.kg("listFocusAndSelectionOutline","List/Tree outline color for the focused item when the list/tree is active and selected. An active list/tree has keyboard focus, an inactive does not.")),St=(0,s.x1)("list.activeSelectionBackground",{dark:"#04395E",light:"#0060C0",hcDark:null,hcLight:r.Q1.fromHex("#0F4A85").transparent(.1)},n.kg("listActiveSelectionBackground","List/Tree background color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),yt=(0,s.x1)("list.activeSelectionForeground",{dark:r.Q1.white,light:r.Q1.white,hcDark:null,hcLight:null},n.kg("listActiveSelectionForeground","List/Tree foreground color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),wt=(0,s.x1)("list.activeSelectionIconForeground",null,n.kg("listActiveSelectionIconForeground","List/Tree icon foreground color for the selected item when the list/tree is active. An active list/tree has keyboard focus, an inactive does not.")),Lt=(0,s.x1)("list.inactiveSelectionBackground",{dark:"#37373D",light:"#E4E6F1",hcDark:null,hcLight:r.Q1.fromHex("#0F4A85").transparent(.1)},n.kg("listInactiveSelectionBackground","List/Tree background color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),Rt=(0,s.x1)("list.inactiveSelectionForeground",null,n.kg("listInactiveSelectionForeground","List/Tree foreground color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),Tt=(0,s.x1)("list.inactiveSelectionIconForeground",null,n.kg("listInactiveSelectionIconForeground","List/Tree icon foreground color for the selected item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),xt=(0,s.x1)("list.inactiveFocusBackground",null,n.kg("listInactiveFocusBackground","List/Tree background color for the focused item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),kt=(0,s.x1)("list.inactiveFocusOutline",null,n.kg("listInactiveFocusOutline","List/Tree outline color for the focused item when the list/tree is inactive. An active list/tree has keyboard focus, an inactive does not.")),At=(0,s.x1)("list.hoverBackground",{dark:"#2A2D2E",light:"#F0F0F0",hcDark:r.Q1.white.transparent(.1),hcLight:r.Q1.fromHex("#0F4A85").transparent(.1)},n.kg("listHoverBackground","List/Tree background when hovering over items using the mouse.")),Nt=(0,s.x1)("list.hoverForeground",null,n.kg("listHoverForeground","List/Tree foreground when hovering over items using the mouse.")),It=(0,s.x1)("list.dropBackground",{dark:"#062F4A",light:"#D6EBFF",hcDark:null,hcLight:null},n.kg("listDropBackground","List/Tree drag and drop background when moving items over other items when using the mouse.")),Ot=(0,s.x1)("list.dropBetweenBackground",{dark:a,light:a,hcDark:null,hcLight:null},n.kg("listDropBetweenBackground","List/Tree drag and drop border color when moving items between items when using the mouse.")),Dt=(0,s.x1)("list.highlightForeground",{dark:"#2AAAFF",light:"#0066BF",hcDark:l,hcLight:l},n.kg("highlight","List/Tree foreground color of the match highlights when searching inside the list/tree.")),Mt=(0,s.x1)("list.focusHighlightForeground",{dark:Dt,light:(0,s.Hz)(St,Dt,"#BBE7FF"),hcDark:Dt,hcLight:Dt},n.kg("listFocusHighlightForeground","List/Tree foreground color of the match highlights on actively focused items when searching inside the list/tree.")),Pt=((0,s.x1)("list.invalidItemForeground",{dark:"#B89500",light:"#B89500",hcDark:"#B89500",hcLight:"#B5200D"},n.kg("invalidItemForeground","List/Tree foreground color for invalid items, for example an unresolved root in explorer.")),(0,s.x1)("list.errorForeground",{dark:"#F88070",light:"#B01011",hcDark:null,hcLight:null},n.kg("listErrorForeground","Foreground color of list items containing errors.")),(0,s.x1)("list.warningForeground",{dark:"#CCA700",light:"#855F00",hcDark:null,hcLight:null},n.kg("listWarningForeground","Foreground color of list items containing warnings.")),(0,s.x1)("listFilterWidget.background",{light:(0,s.e$)(E,0),dark:(0,s.a)(E,0),hcDark:E,hcLight:E},n.kg("listFilterWidgetBackground","Background color of the type filter widget in lists and trees."))),Ft=(0,s.x1)("listFilterWidget.outline",{dark:r.Q1.transparent,light:r.Q1.transparent,hcDark:"#f38518",hcLight:"#007ACC"},n.kg("listFilterWidgetOutline","Outline color of the type filter widget in lists and trees.")),Ut=(0,s.x1)("listFilterWidget.noMatchesOutline",{dark:"#BE1100",light:"#BE1100",hcDark:c,hcLight:c},n.kg("listFilterWidgetNoMatchesOutline","Outline color of the type filter widget in lists and trees, when there are no matches.")),Ht=(0,s.x1)("listFilterWidget.shadow",se,n.kg("listFilterWidgetShadow","Shadow color of the type filter widget in lists and trees.")),Bt=((0,s.x1)("list.filterMatchBackground",{dark:U,light:U,hcDark:null,hcLight:null},n.kg("listFilterMatchHighlight","Background color of the filtered match.")),(0,s.x1)("list.filterMatchBorder",{dark:B,light:B,hcDark:c,hcLight:h},n.kg("listFilterMatchHighlightBorder","Border color of the filtered match.")),(0,s.x1)("list.deemphasizedForeground",{dark:"#8C8C8C",light:"#8E8E90",hcDark:"#A7A8A9",hcLight:"#666666"},n.kg("listDeemphasizedForeground","List/Tree foreground color for items that are deemphasized.")),(0,s.x1)("tree.indentGuidesStroke",{dark:"#585858",light:"#a9a9a9",hcDark:"#a9a9a9",hcLight:"#a5a5a5"},n.kg("treeIndentGuidesStroke","Tree stroke color for the indentation guides."))),Wt=(0,s.x1)("tree.inactiveIndentGuidesStroke",(0,s.JO)(Bt,.4),n.kg("treeInactiveIndentGuidesStroke","Tree stroke color for the indentation guides that are not active.")),Vt=(0,s.x1)("tree.tableColumnsBorder",{dark:"#CCCCCC20",light:"#61616120",hcDark:null,hcLight:null},n.kg("tableColumnsBorder","Table border color between columns.")),zt=(0,s.x1)("tree.tableOddRowsBackground",{dark:(0,s.JO)(o,.04),light:(0,s.JO)(o,.04),hcDark:null,hcLight:null},n.kg("tableOddRowsBackgroundColor","Background color for odd table rows.")),Gt=((0,s.x1)("editorActionList.background",E,n.kg("editorActionListBackground","Action List background color.")),(0,s.x1)("editorActionList.foreground",S,n.kg("editorActionListForeground","Action List foreground color.")),(0,s.x1)("editorActionList.focusForeground",yt,n.kg("editorActionListFocusForeground","Action List foreground color for the focused item.")),(0,s.x1)("editorActionList.focusBackground",St,n.kg("editorActionListFocusBackground","Action List background color for the focused item.")),(0,s.x1)("menu.border",{dark:null,light:null,hcDark:c,hcLight:c},n.kg("menuBorder","Border color of menus."))),jt=(0,s.x1)("menu.foreground",qe,n.kg("menuForeground","Foreground color of menu items.")),Kt=(0,s.x1)("menu.background",Ke,n.kg("menuBackground","Background color of menu items.")),Yt=(0,s.x1)("menu.selectionForeground",yt,n.kg("menuSelectionForeground","Foreground color of the selected menu item in menus.")),qt=(0,s.x1)("menu.selectionBackground",St,n.kg("menuSelectionBackground","Background color of the selected menu item in menus.")),$t=(0,s.x1)("menu.selectionBorder",{dark:null,light:null,hcDark:h,hcLight:h},n.kg("menuSelectionBorder","Border color of the selected menu item in menus.")),Qt=(0,s.x1)("menu.separatorBackground",{dark:"#606060",light:"#D4D4D4",hcDark:c,hcLight:c},n.kg("menuSeparatorBackground","Color of a separator menu item in menus.")),Xt=(0,s.x1)("quickInput.background",E,n.kg("pickerBackground","Quick picker background color. The quick picker widget is the container for pickers like the command palette.")),Zt=(0,s.x1)("quickInput.foreground",S,n.kg("pickerForeground","Quick picker foreground color. The quick picker widget is the container for pickers like the command palette.")),Jt=(0,s.x1)("quickInputTitle.background",{dark:new r.Q1(new r.bU(255,255,255,.105)),light:new r.Q1(new r.bU(0,0,0,.06)),hcDark:"#000000",hcLight:r.Q1.white},n.kg("pickerTitleBackground","Quick picker title background color. The quick picker widget is the container for pickers like the command palette.")),ei=(0,s.x1)("pickerGroup.foreground",{dark:"#3794FF",light:"#0066BF",hcDark:r.Q1.white,hcLight:"#0F4A85"},n.kg("pickerGroupForeground","Quick picker color for grouping labels.")),ti=(0,s.x1)("pickerGroup.border",{dark:"#3F3F46",light:"#CCCEDB",hcDark:r.Q1.white,hcLight:"#0F4A85"},n.kg("pickerGroupBorder","Quick picker color for grouping borders.")),ii=(0,s.x1)("quickInput.list.focusBackground",null,"",void 0,n.kg("quickInput.list.focusBackground deprecation","Please use quickInputList.focusBackground instead")),si=(0,s.x1)("quickInputList.focusForeground",yt,n.kg("quickInput.listFocusForeground","Quick picker foreground color for the focused item.")),ni=(0,s.x1)("quickInputList.focusIconForeground",wt,n.kg("quickInput.listFocusIconForeground","Quick picker icon foreground color for the focused item.")),ri=(0,s.x1)("quickInputList.focusBackground",{dark:(0,s.yL)(ii,St),light:(0,s.yL)(ii,St),hcDark:null,hcLight:null},n.kg("quickInput.listFocusBackground","Quick picker background color for the focused item."));(0,s.x1)("search.resultsInfoForeground",{light:o,dark:(0,s.JO)(o,.65),hcDark:o,hcLight:o},n.kg("search.resultsInfoForeground","Color of the text in the search viewlet's completion message.")),(0,s.x1)("searchEditor.findMatchBackground",{light:(0,s.JO)(U,.66),dark:(0,s.JO)(U,.66),hcDark:U,hcLight:U},n.kg("searchEditor.queryMatch","Color of the Search Editor query matches.")),(0,s.x1)("searchEditor.findMatchBorder",{light:(0,s.JO)(B,.66),dark:(0,s.JO)(B,.66),hcDark:B,hcLight:B},n.kg("searchEditor.editorFindMatchBorder","Border color of the Search Editor query matches."))},83844:(e,t,i)=>{"use strict";i.d(t,{Bb:()=>h,Fd:()=>g,Gu:()=>d,HP:()=>u,Hz:()=>b,JO:()=>v,a:()=>_,e$:()=>f,oG:()=>E,x1:()=>m,yL:()=>C});var s=i(66782),n=i(90766),r=i(47661),o=i(41234),a=i(78748),l=i(46359),c=i(78209);function h(e){return`--vscode-${e.replace(/\./g,"-")}`}function d(e){return`var(${h(e)})`}function u(e,t){return`var(${h(e)}, ${t})`}const g={ColorContribution:"base.contributions.colors"};const p=new class{constructor(){this._onDidChangeSchema=new o.vl,this.onDidChangeSchema=this._onDidChangeSchema.event,this.colorSchema={type:"object",properties:{}},this.colorReferenceSchema={type:"string",enum:[],enumDescriptions:[]},this.colorsById={}}registerColor(e,t,i,s=!1,n){const r={id:e,description:i,defaults:t,needsTransparency:s,deprecationMessage:n};this.colorsById[e]=r;const o={type:"string",format:"color-hex",defaultSnippets:[{body:"${1:#ff0000}"}]};return n&&(o.deprecationMessage=n),s&&(o.pattern="^#(?:(?[0-9a-fA-f]{3}[0-9a-eA-E])|(?:[0-9a-fA-F]{6}(?:(?![fF]{2})(?:[0-9a-fA-F]{2}))))?$",o.patternErrorMessage=c.kg("transparecyRequired","This color must be transparent or it will obscure content")),this.colorSchema.properties[e]={description:i,oneOf:[o,{type:"string",const:"default",description:c.kg("useDefault","Use the default color.")}]},this.colorReferenceSchema.enum.push(e),this.colorReferenceSchema.enumDescriptions.push(i),this._onDidChangeSchema.fire(),e}getColors(){return Object.keys(this.colorsById).map((e=>this.colorsById[e]))}resolveDefaultColor(e,t){const i=this.colorsById[e];if(i?.defaults){return S(null!==(s=i.defaults)&&"object"===typeof s&&"light"in s&&"dark"in s?i.defaults[t.type]:i.defaults,t)}var s}getColorSchema(){return this.colorSchema}toString(){return Object.keys(this.colorsById).sort(((e,t)=>{const i=-1===e.indexOf(".")?0:1,s=-1===t.indexOf(".")?0:1;return i!==s?i-s:e.localeCompare(t)})).map((e=>`- \`${e}\`: ${this.colorsById[e].description}`)).join("\n")}};function m(e,t,i,s,n){return p.registerColor(e,t,i,s,n)}function f(e,t){return{op:0,value:e,factor:t}}function _(e,t){return{op:1,value:e,factor:t}}function v(e,t){return{op:2,value:e,factor:t}}function C(...e){return{op:4,values:e}}function b(e,t,i){return{op:6,if:e,then:t,else:i}}function E(e,t,i,s){return{op:5,value:e,background:t,factor:i,transparency:s}}function S(e,t){if(null!==e)return"string"===typeof e?"#"===e[0]?r.Q1.fromHex(e):t.getColor(e):e instanceof r.Q1?e:"object"===typeof e?function(e,t){switch(e.op){case 0:return S(e.value,t)?.darken(e.factor);case 1:return S(e.value,t)?.lighten(e.factor);case 2:return S(e.value,t)?.transparent(e.factor);case 3:{const i=S(e.background,t);return i?S(e.value,t)?.makeOpaque(i):S(e.value,t)}case 4:for(const i of e.values){const e=S(i,t);if(e)return e}return;case 6:return S(t.defines(e.if)?e.then:e.else,t);case 5:{const i=S(e.value,t);if(!i)return;const s=S(e.background,t);return s?i.isDarkerThan(s)?r.Q1.getLighterColor(i,s,e.factor).transparent(e.transparency):r.Q1.getDarkerColor(i,s,e.factor).transparent(e.transparency):i.transparent(e.factor*e.transparency)}default:throw(0,s.xb)(e)}}(e,t):void 0}l.O.add(g.ColorContribution,p);const y="vscode://schemas/workbench-colors",w=l.O.as(a.F.JSONContribution);w.registerSchema(y,p.getColorSchema());const L=new n.uC((()=>w.notifySchemaChanged(y)),200);p.onDidChangeSchema((()=>{L.isScheduled()||L.schedule()}))},61394:(e,t,i)=>{"use strict";i.d(t,{$_:()=>E,HT:()=>_,pU:()=>f});var s=i(90766),n=i(10350),r=i(18956),o=i(25689),a=i(41234),l=i(631),c=i(79400),h=i(78209),d=i(78748),u=i(46359);var g,p;!function(e){e.getDefinition=function(e,t){let i=e.defaults;for(;o.L.isThemeIcon(i);){const e=m.getIcon(i.id);if(!e)return;i=e.defaults}return i}}(g||(g={})),function(e){e.toJSONObject=function(e){return{weight:e.weight,style:e.style,src:e.src.map((e=>({format:e.format,location:e.location.toString()})))}},e.fromJSONObject=function(e){const t=e=>(0,l.Kg)(e)?e:void 0;if(e&&Array.isArray(e.src)&&e.src.every((e=>(0,l.Kg)(e.format)&&(0,l.Kg)(e.location))))return{weight:t(e.weight),style:t(e.style),src:e.src.map((e=>({format:e.format,location:c.r.parse(e.location)})))}}}(p||(p={}));const m=new class{constructor(){this._onDidChange=new a.vl,this.onDidChange=this._onDidChange.event,this.iconSchema={definitions:{icons:{type:"object",properties:{fontId:{type:"string",description:(0,h.kg)("iconDefinition.fontId","The id of the font to use. If not set, the font that is defined first is used.")},fontCharacter:{type:"string",description:(0,h.kg)("iconDefinition.fontCharacter","The font character associated with the icon definition.")}},additionalProperties:!1,defaultSnippets:[{body:{fontCharacter:"\\\\e030"}}]}},type:"object",properties:{}},this.iconReferenceSchema={type:"string",pattern:`^${o.L.iconNameExpression}$`,enum:[],enumDescriptions:[]},this.iconsById={},this.iconFontsById={}}registerIcon(e,t,i,s){const n=this.iconsById[e];if(n){if(i&&!n.description){n.description=i,this.iconSchema.properties[e].markdownDescription=`${i} $(${e})`;const t=this.iconReferenceSchema.enum.indexOf(e);-1!==t&&(this.iconReferenceSchema.enumDescriptions[t]=i),this._onDidChange.fire()}return n}const r={id:e,description:i,defaults:t,deprecationMessage:s};this.iconsById[e]=r;const o={$ref:"#/definitions/icons"};return s&&(o.deprecationMessage=s),i&&(o.markdownDescription=`${i}: $(${e})`),this.iconSchema.properties[e]=o,this.iconReferenceSchema.enum.push(e),this.iconReferenceSchema.enumDescriptions.push(i||""),this._onDidChange.fire(),{id:e}}getIcons(){return Object.keys(this.iconsById).map((e=>this.iconsById[e]))}getIcon(e){return this.iconsById[e]}getIconSchema(){return this.iconSchema}toString(){const e=(e,t)=>e.id.localeCompare(t.id),t=e=>{for(;o.L.isThemeIcon(e.defaults);)e=this.iconsById[e.defaults.id];return`codicon codicon-${e?e.id:""}`},i=[];i.push("| preview | identifier | default codicon ID | description"),i.push("| ----------- | --------------------------------- | --------------------------------- | --------------------------------- |");const s=Object.keys(this.iconsById).map((e=>this.iconsById[e]));for(const n of s.filter((e=>!!e.description)).sort(e))i.push(`||${n.id}|${o.L.isThemeIcon(n.defaults)?n.defaults.id:n.id}|${n.description||""}|`);i.push("| preview | identifier "),i.push("| ----------- | --------------------------------- |");for(const n of s.filter((e=>!o.L.isThemeIcon(e.defaults))).sort(e))i.push(`||${n.id}|`);return i.join("\n")}};function f(e,t,i,s){return m.registerIcon(e,t,i,s)}function _(){return m}u.O.add("base.contributions.icons",m),function(){const e=(0,r.J)();for(const t in e){const i="\\"+e[t].toString(16);m.registerIcon(t,{fontCharacter:i})}}();const v="vscode://schemas/icons",C=u.O.as(d.F.JSONContribution);C.registerSchema(v,m.getIconSchema());const b=new s.uC((()=>C.notifySchemaChanged(v)),200);m.onDidChange((()=>{b.isScheduled()||b.schedule()}));const E=f("widget-close",n.W.close,(0,h.kg)("widgetClose","Icon for the close action in widgets."));f("goto-previous-location",n.W.arrowUp,(0,h.kg)("previousChangeIcon","Icon for goto previous editor location.")),f("goto-next-location",n.W.arrowDown,(0,h.kg)("nextChangeIcon","Icon for goto next editor location.")),o.L.modify(n.W.sync,"spin"),o.L.modify(n.W.loading,"spin")},86723:(e,t,i)=>{"use strict";var s;function n(e){return e===s.HIGH_CONTRAST_DARK||e===s.HIGH_CONTRAST_LIGHT}function r(e){return e===s.DARK||e===s.HIGH_CONTRAST_DARK}i.d(t,{Bb:()=>n,HD:()=>r,zM:()=>s}),function(e){e.DARK="dark",e.LIGHT="light",e.HIGH_CONTRAST_DARK="hcDark",e.HIGH_CONTRAST_LIGHT="hcLight"}(s||(s={}))},47612:(e,t,i)=>{"use strict";i.d(t,{Fd:()=>d,Gy:()=>l,Pz:()=>h,Yf:()=>c,lR:()=>p,zy:()=>g});var s=i(41234),n=i(5662),r=i(63591),o=i(46359),a=i(86723);const l=(0,r.u1)("themeService");function c(e){return{id:e}}function h(e){switch(e){case a.zM.DARK:return"vs-dark";case a.zM.HIGH_CONTRAST_DARK:return"hc-black";case a.zM.HIGH_CONTRAST_LIGHT:return"hc-light";default:return"vs"}}const d={ThemingContribution:"base.contributions.theming"};const u=new class{constructor(){this.themingParticipants=[],this.themingParticipants=[],this.onThemingParticipantAddedEmitter=new s.vl}onColorThemeChange(e){return this.themingParticipants.push(e),this.onThemingParticipantAddedEmitter.fire(e),(0,n.s)((()=>{const t=this.themingParticipants.indexOf(e);this.themingParticipants.splice(t,1)}))}getThemingParticipants(){return this.themingParticipants}};function g(e){return u.onColorThemeChange(e)}o.O.add(d.ThemingContribution,u);class p extends n.jG{constructor(e){super(),this.themeService=e,this.theme=e.getColorTheme(),this._register(this.themeService.onDidColorThemeChange((e=>this.onThemeChange(e))))}onThemeChange(e){this.theme=e,this.updateStyles()}updateStyles(){}}},47579:(e,t,i)=>{"use strict";i.d(t,{$D:()=>s,I_:()=>r,To:()=>n,Ym:()=>o});const s=(0,i(63591).u1)("undoRedoService");class n{constructor(e,t){this.resource=e,this.elements=t}}class r{static{this._ID=0}constructor(){this.id=r._ID++,this.order=1}nextOrder(){return 0===this.id?0:this.order++}static{this.None=new r}}class o{static{this._ID=0}constructor(){this.id=o._ID++,this.order=1}nextOrder(){return 0===this.id?0:this.order++}static{this.None=new o}}},37227:(e,t,i)=>{"use strict";i.d(t,{A7:()=>l,Q_:()=>d,VR:()=>o,cn:()=>p,ct:()=>m,jB:()=>a,kF:()=>g,mX:()=>u});var s=i(78209),n=i(74027),r=(i(4853),i(79400));const o=(0,i(63591).u1)("contextService");function a(e){const t=e;return"string"===typeof t?.id&&r.r.isUri(t.uri)}function l(e){const t=e;return"string"===typeof t?.id&&!a(e)&&!function(e){const t=e;return"string"===typeof t?.id&&r.r.isUri(t.configPath)}(e)}const c={id:"ext-dev"},h={id:"empty-window"};function d(e,t){if("string"===typeof e||"undefined"===typeof e)return"string"===typeof e?{id:(0,n.P8)(e)}:t?c:h;const i=e;return i.configuration?{id:i.id,configPath:i.configuration}:1===i.folders.length?{id:i.id,uri:i.folders[0].uri}:{id:i.id}}class u{constructor(e,t){this.raw=t,this.uri=e.uri,this.index=e.index,this.name=e.name}toJSON(){return{uri:this.uri,name:this.name,index:this.index}}}const g="code-workspace",p=((0,s.kg)("codeWorkspace","Code Workspace"),"4064f6ec-cb38-4ad0-af64-ee6467e63c82");function m(e){return e.id===p}},51465:(e,t,i)=>{"use strict";i.d(t,{L:()=>s});const s=(0,i(63591).u1)("workspaceTrustManagementService")},61850:(e,t,i)=>{"use strict";i.d(t,{IK:()=>h,bC:()=>u,RQ:()=>d,KV:()=>l});const s=new RegExp("^[$A-Z_\\s]+$");var n=i(92727);const r={},o={};class a{static getOrCreate(e){return o[e]||(o[e]=new a(e)),o[e]}constructor(e){this._languageId=e,this._loadingTriggered=!1,this._lazyLoadPromise=new Promise(((e,t)=>{this._lazyLoadPromiseResolve=e,this._lazyLoadPromiseReject=t}))}whenLoaded(){return this._lazyLoadPromise}load(){return this._loadingTriggered||(this._loadingTriggered=!0,r[this._languageId].loader().then((e=>this._lazyLoadPromiseResolve(e)),(e=>this._lazyLoadPromiseReject(e)))),this._lazyLoadPromise}}function l(e){const t=e.id;r[t]=e,n.eo.register(e);const i=a.getOrCreate(t);n.eo.setMonarchTokensProvider(t,i.whenLoaded().then((e=>e.language))),n.eo.onLanguage(t,(()=>{i.load().then((e=>{n.eo.setLanguageConfiguration(t,e.conf)}))})),i.whenLoaded().then((e=>{e.completions&&c(t,e.completions)}))}function c(e,t){const i=[];const r=n.eo[e];r&&!r.modeConfiguration.completionItems||i.push(n.eo.registerCompletionItemProvider(e,function(e,t){const i=[];for(const n in t)if(!isNaN(Number(n))){const r=`${t[n].toLowerCase()}List`;if(r in e)for(const t of e[r])i.push({label:t,filterText:s.test(t)?t.toLowerCase():t,insertText:t,kind:Number(n),range:{startLineNumber:1,startColumn:1,endLineNumber:1,endColumn:1}})}return i.sort(((e,t)=>e.filterText.localeCompare(t.filterText))),{provideCompletionItems(e,t,s,n){const r=e.getWordUntilPosition(t),o={startLineNumber:t.lineNumber,startColumn:r.startColumn,endLineNumber:t.lineNumber,endColumn:r.endColumn};return{suggestions:i.map((e=>Object.assign(Object.assign({},e),{range:o})))}}}}(t,n.eo.CompletionItemKind))),r&&i.push(r.onDidChange((()=>{!function(){for(var e;i.length>0;)null===(e=i.pop())||void 0===e||e.dispose()}(),c(e,t)})))}class h{constructor(e,t,i){this._onDidChange=new n.vl,this._languageId=e,this.setDiagnosticsOptions(t),this.setModeConfiguration(i)}get onDidChange(){return this._onDidChange.event}get languageId(){return this._languageId}get modeConfiguration(){return this._modeConfiguration}get diagnosticsOptions(){return this._diagnosticsOptions}setDiagnosticsOptions(e){this._diagnosticsOptions=e||Object.create(null),this._onDidChange.fire(this)}setModeConfiguration(e){this._modeConfiguration=e||Object.create(null),this._onDidChange.fire(this)}}const d={completionItems:!0,hovers:!0,documentSymbols:!0,definitions:!0,references:!0,documentHighlights:!0,rename:!0,colors:!0,foldingRanges:!0,diagnostics:!0,selectionRanges:!0},u={validate:!0}},92727:(e,t,i)=>{"use strict";i.d(t,{EN:()=>s.editor,eo:()=>s.languages,vl:()=>s.Emitter});var s=i(80781)},23934:(e,t,i)=>{"use strict";var s=i(61850),n=i(92727);const r="clickhouse";(0,s.KV)({id:r,extensions:[],loader:()=>i.e(6397).then(i.bind(i,66397)).then((e=>({conf:e.conf,language:e.language,completions:e.completionLists})))});const o=new s.IK(r,s.bC,s.RQ);n.eo[r]=o;(0,s.KV)({id:"s-expression",extensions:[],loader:()=>i.e(5475).then(i.bind(i,5475))}),n.EN.defineTheme("vs",{base:"vs",inherit:!0,rules:[{token:"string.tablepath",foreground:"338186"},{token:"constant.yql",foreground:"608b4e"},{token:"keyword.type",foreground:"4d932d"},{token:"string.sql",foreground:"a31515"},{token:"support.function",foreground:"7a3e9d"},{token:"constant.other.color",foreground:"7a3e9d"},{token:"comment",foreground:"969896"}],colors:{"editor.lineHighlightBackground":"#EFEFEF"}}),n.EN.defineTheme("vs-dark",{base:"vs-dark",inherit:!0,rules:[{token:"string.tablepath",foreground:"338186"},{token:"constant.yql",foreground:"608b4e"},{token:"storage.type",foreground:"6A8759"},{token:"string.sql",foreground:"ce9178"},{token:"support.function",foreground:"9e7bb0"},{token:"constant.other.color",foreground:"9e7bb0"},{token:"comment",foreground:"969896"}],colors:{"editor.lineHighlightBackground":"#282A2E"}});i(23195);(0,s.KV)({id:"yql_ansi",extensions:[],loader:()=>i.e(9507).then(i.bind(i,19507)).then((e=>({conf:e.conf,language:e.getLanguage({ansi:!0})})))});i(43733)},23195:(e,t,i)=>{"use strict";i.d(t,{l:()=>n});var s=i(61850);const n="yql";(0,s.KV)({id:n,extensions:[],loader:()=>i.e(9507).then(i.bind(i,19507)).then((e=>({conf:e.conf,language:e.getLanguage()})))})},67796:e=>{"use strict";var t=Object.getOwnPropertySymbols,i=Object.prototype.hasOwnProperty,s=Object.prototype.propertyIsEnumerable;e.exports=function(){try{if(!Object.assign)return!1;var e=new String("abc");if(e[5]="de","5"===Object.getOwnPropertyNames(e)[0])return!1;for(var t={},i=0;i<10;i++)t["_"+String.fromCharCode(i)]=i;if("0123456789"!==Object.getOwnPropertyNames(t).map((function(e){return t[e]})).join(""))return!1;var s={};return"abcdefghijklmnopqrst".split("").forEach((function(e){s[e]=e})),"abcdefghijklmnopqrst"===Object.keys(Object.assign({},s)).join("")}catch(n){return!1}}()?Object.assign:function(e,n){for(var r,o,a=function(e){if(null===e||void 0===e)throw new TypeError("Object.assign cannot be called with null or undefined");return Object(e)}(e),l=1;l{var s=i(59284),n=i(14538),r=i(13260),o=i(41470),a=s.createElement,l=i(52893),c=i(74073),h=i(46556),d=i(53753),u=i(53205),g=i(23909);e.exports=n({propTypes:{data:r.any.isRequired,search:r.oneOfType([r.func,r.bool]),searchOptions:r.shape({debounceTime:r.number}),onClick:r.func,validateQuery:r.func,isExpanded:r.func,filterOptions:r.shape({cacheResults:r.bool,ignoreCase:r.bool}),query:r.string,verboseShowOriginal:r.bool},getDefaultProps:function(){return{data:null,search:c,searchOptions:{debounceTime:0},className:"",id:"json-"+Date.now(),onClick:g,filterOptions:{cacheResults:!0,ignoreCase:!1},validateQuery:function(e){return e.length>=2},isExpanded:function(e,t){return!1},verboseShowOriginal:!1}},getInitialState:function(){return{query:this.props.query||""}},render:function(){var e=this.props,t=this.state,i=""!==t.query&&e.validateQuery(t.query),s=i?t.filterer(t.query):e.data,n=i&&d(s);return a("div",{className:"json-inspector "+e.className},this.renderToolbar(),n?a("div",{className:"json-inspector__not-found"},"Nothing found"):a(l,{data:s,onClick:e.onClick,id:e.id,getOriginal:this.getOriginal,query:i?new RegExp(t.query,e.filterOptions.ignoreCase?"i":""):null,label:"root",root:!0,isExpanded:e.isExpanded,interactiveLabel:e.interactiveLabel,verboseShowOriginal:e.verboseShowOriginal}))},renderToolbar:function(){var e=this.props.search;if(e)return a("div",{className:"json-inspector__toolbar"},a(e,{onChange:o(this.search,this.props.searchOptions.debounceTime),data:this.props.data,query:this.state.query}))},search:function(e){this.setState({query:e})},componentWillMount:function(){this.createFilterer(this.props.data,this.props.filterOptions)},componentWillReceiveProps:function(e){this.createFilterer(e.data,e.filterOptions),"string"===typeof e.query&&e.query!==this.state.query&&this.setState({query:e.query})},shouldComponentUpdate:function(e,t){return e.query!==this.props.query||t.query!==this.state.query||e.data!==this.props.data||e.onClick!==this.props.onClick},createFilterer:function(e,t){this.setState({filterer:h(e,t)})},getOriginal:function(e){return u(this.props.data,e)}})},46556:(e,t,i)=>{var s=i(40652),n=Object.keys,r=i(63817),o=i(53753);function a(e,t,i){return n(e).reduce((function(n,c){var h,d=e[c];return r(d)?(l(t,c,i)||l(t,d,i))&&(n[c]=d):l(t,c,i)?n[c]=d:(h=a(d,t,i),o(h)||s(n,function(e,t){var i={};return i[e]=t,i}(c,h))),n}),{})}function l(e,t,i){if(t){var s=String(t),n=e;return i.ignoreCase&&(s=s.toLowerCase(),n=n.toLowerCase()),-1!==s.indexOf(n)}}e.exports=function(e,t){t||(t={cacheResults:!0});var i={};return function(s){if(!t.cacheResults)return a(e,s,t);var n;if(!i[s])for(var r=s.length-1;r>0;r-=1)if(n=s.substr(0,r),i[n]){i[s]=a(i[n],s,t);break}return i[s]||(i[s]=a(e,s,t)),i[s]}}},49022:(e,t,i)=>{var s=i(59284),n=i(14538),r=s.createElement;e.exports=n({getDefaultProps:function(){return{string:"",highlight:""}},shouldComponentUpdate:function(e){return e.highlight!==this.props.highlight},render:function(){var e=this.props,t=e.string.search(e.highlight);if(!e.highlight||-1===t)return r("span",null,e.string);var i=e.highlight.source.length,s=e.string.substr(t,i);return r("span",null,e.string.split(e.highlight).map((function(e,t){return r("span",{key:t},t>0?r("span",{className:"json-inspector__hl"},s):null,e)})))}})},53753:e=>{e.exports=function(e){return 0===Object.keys(e).length}},63817:(e,t,i)=>{var s=i(67857);e.exports=function(e){var t=s(e);return"Object"!==t&&"Array"!==t}},52893:(e,t,i)=>{var s=i(59284),n=i(14538),r=i(1445),o=i(68155),a=i(67857),l=i(63817),c=i(49022),h=s.createElement,d=n({getInitialState:function(){return{expanded:this._isInitiallyExpanded(this.props)}},getDefaultProps:function(){return{root:!1,prefix:""}},render:function(){var e="id_"+o(),t=this.props,i={path:this.keypath(),key:t.label.toString(),value:t.data},s=this._onClick.bind(this,i);return h("div",{className:this.getClassName(),id:"leaf-"+this._rootPath()},h("input",{className:"json-inspector__radio",type:"radio",name:t.id,id:e,tabIndex:-1}),h("label",{className:"json-inspector__line",htmlFor:e,onClick:s},h("div",{className:"json-inspector__flatpath"},i.path),h("span",{className:"json-inspector__key"},this.format(i.key),":",this.renderInteractiveLabel(i.key,!0)),this.renderTitle(),this.renderShowOriginalButton()),this.renderChildren())},renderTitle:function(){var e=this.data(),t=a(e);switch(t){case"Array":return h("span",{className:"json-inspector__value json-inspector__value_helper"},"[] "+u(e.length));case"Object":return h("span",{className:"json-inspector__value json-inspector__value_helper"},"{} "+u(Object.keys(e).length));default:return h("span",{className:"json-inspector__value json-inspector__value_"+t.toLowerCase()},this.format(String(e)),this.renderInteractiveLabel(e,!1))}},renderChildren:function(){var e=this.props,t=this._rootPath(),i=this.data();return this.state.expanded&&!l(i)?Object.keys(i).map((function(s){var n=i[s],r=!this.state.original||!!e.verboseShowOriginal&&e.query;return h(d,{data:n,label:s,prefix:t,onClick:e.onClick,id:e.id,query:e.query,getOriginal:r?e.getOriginal:null,key:g(s,n),isExpanded:e.isExpanded,interactiveLabel:e.interactiveLabel,verboseShowOriginal:e.verboseShowOriginal})}),this):null},renderShowOriginalButton:function(){var e=this.props;return l(e.data)||this.state.original||!e.getOriginal||!e.query||p(this.keypath(),e.query)?null:h("span",{className:"json-inspector__show-original",onClick:this._onShowOriginalClick})},renderInteractiveLabel:function(e,t){return"function"===typeof this.props.interactiveLabel?h(this.props.interactiveLabel,{value:String(e),originalValue:e,isKey:t,keypath:this.keypath()}):null},componentWillReceiveProps:function(e){e.query&&this.setState({expanded:!p(e.label,e.query)}),this.props.query&&!e.query&&this.setState({expanded:this._isInitiallyExpanded(e)})},_rootPath:function(){return this.props.prefix+"."+this.props.label},keypath:function(){return this._rootPath().substr(6)},data:function(){return this.state.original||this.props.data},format:function(e){return h(c,{string:e,highlight:this.props.query})},getClassName:function(){var e="json-inspector__leaf";return this.props.root&&(e+=" json-inspector__leaf_root"),this.state.expanded&&(e+=" json-inspector__leaf_expanded"),l(this.props.data)||(e+=" json-inspector__leaf_composite"),e},toggle:function(){this.setState({expanded:!this.state.expanded})},_onClick:function(e,t){this.toggle(),this.props.onClick(e),t.stopPropagation()},_onShowOriginalClick:function(e){this.setState({original:this.props.getOriginal(this.keypath())}),e.stopPropagation()},_isInitiallyExpanded:function(e){var t=this.keypath();return!!e.root||(e.query?!p(t,e.query)&&"function"===typeof e.getOriginal:e.isExpanded(t,e.data))}});function u(e){return e+(1===e?" item":" items")}function g(e,t){return l(t)?e+":"+r(String(t)):e+"["+a(t)+"]"}function p(e,t){return-1!==e.indexOf(t)}e.exports=d},53205:(e,t,i)=>{var s=i(67857);function n(e){return parseInt(e,10)}e.exports=function e(t,i){var r=i.split("."),o=r.shift();if(!o)return t;var a=s(t);return"Array"===a&&t[n(o)]?e(t[n(o)],r.join(".")):"Object"===a&&t[o]?e(t[o],r.join(".")):void 0}},23909:e=>{e.exports=function(){}},74073:(e,t,i)=>{var s=i(59284),n=i(14538),r=s.createElement,o=i(23909);e.exports=n({getDefaultProps:function(){return{onChange:o}},render:function(){return r("input",{className:"json-inspector__search",type:"search",placeholder:"Search",onChange:this.onChange})},onChange:function(e){this.props.onChange(e.target.value)}})},67857:e=>{e.exports=function(e){return Object.prototype.toString.call(e).slice(8,-1)}},68155:e=>{var t=Math.ceil(10*Math.random());e.exports=function(){return++t}},40652:e=>{"use strict";e.exports=Object.assign||function(e,t){for(var i,s,n=function(e){if(null==e)throw new TypeError("Object.assign cannot be called with null or undefined");return Object(e)}(e),r=1;r{"use strict";i.r(t),i.d(t,{MonacoDiffEditor:()=>c,default:()=>g,monaco:()=>s});var s=i(80781),n=i(59284);function r(e){return/^\d+$/.test(e)?"".concat(e,"px"):e}function o(){}var a=function(){return a=Object.assign||function(e){for(var t,i=1,s=arguments.length;i{"use strict";i.d(t,{A:()=>x});var s=i(59284),n=i(13260),r=i.n(n),o="undefined"!==typeof window?window:null,a=null===o,l=a?void 0:o.document,c="addEventListener",h="removeEventListener",d="getBoundingClientRect",u="_a",g="_b",p="_c",m="horizontal",f=function(){return!1},_=a?"calc":["","-webkit-","-moz-","-o-"].filter((function(e){var t=l.createElement("div");return t.style.cssText="width:"+e+"calc(9px)",!!t.style.length})).shift()+"calc",v=function(e){return"string"===typeof e||e instanceof String},C=function(e){if(v(e)){var t=l.querySelector(e);if(!t)throw new Error("Selector "+e+" did not match a DOM element");return t}return e},b=function(e,t,i){var s=e[t];return void 0!==s?s:i},E=function(e,t,i,s){if(t){if("end"===s)return 0;if("center"===s)return e/2}else if(i){if("start"===s)return 0;if("center"===s)return e/2}return e},S=function(e,t){var i=l.createElement("div");return i.className="gutter gutter-"+t,i},y=function(e,t,i){var s={};return v(t)?s[e]=t:s[e]=_+"("+t+"% - "+i+"px)",s},w=function(e,t){var i;return(i={})[e]=t+"px",i};const L=function(e,t){if(void 0===t&&(t={}),a)return{};var i,s,n,r,_,v,L=e;Array.from&&(L=Array.from(L));var R=C(L[0]).parentNode,T=getComputedStyle?getComputedStyle(R):null,x=T?T.flexDirection:null,k=b(t,"sizes")||L.map((function(){return 100/L.length})),A=b(t,"minSize",100),N=Array.isArray(A)?A:L.map((function(){return A})),I=b(t,"maxSize",1/0),O=Array.isArray(I)?I:L.map((function(){return I})),D=b(t,"expandToMin",!1),M=b(t,"gutterSize",10),P=b(t,"gutterAlign","center"),F=b(t,"snapOffset",30),U=Array.isArray(F)?F:L.map((function(){return F})),H=b(t,"dragInterval",1),B=b(t,"direction",m),W=b(t,"cursor",B===m?"col-resize":"row-resize"),V=b(t,"gutter",S),z=b(t,"elementStyle",y),G=b(t,"gutterStyle",w);function j(e,t,s,n){var r=z(i,t,s,n);Object.keys(r).forEach((function(t){e.style[t]=r[t]}))}function K(){return v.map((function(e){return e.size}))}function Y(e){return"touches"in e?e.touches[0][s]:e[s]}function q(e){var t=v[this.a],i=v[this.b],s=t.size+i.size;t.size=e/this.size*s,i.size=s-e/this.size*s,j(t.element,t.size,this[g],t.i),j(i.element,i.size,this[p],i.i)}function $(e){var i,s=v[this.a],n=v[this.b];this.dragging&&(i=Y(e)-this.start+(this[g]-this.dragOffset),H>1&&(i=Math.round(i/H)*H),i<=s.minSize+s.snapOffset+this[g]?i=s.minSize+this[g]:i>=this.size-(n.minSize+n.snapOffset+this[p])&&(i=this.size-(n.minSize+this[p])),i>=s.maxSize-s.snapOffset+this[g]?i=s.maxSize+this[g]:i<=this.size-(n.maxSize-n.snapOffset+this[p])&&(i=this.size-(n.maxSize+this[p])),q.call(this,i),b(t,"onDrag",f)(K()))}function Q(){var e=v[this.a].element,t=v[this.b].element,s=e[d](),o=t[d]();this.size=s[i]+o[i]+this[g]+this[p],this.start=s[n],this.end=s[r]}function X(e){var t=function(e){if(!getComputedStyle)return null;var t=getComputedStyle(e);if(!t)return null;var i=e[_];return 0===i?null:i-=B===m?parseFloat(t.paddingLeft)+parseFloat(t.paddingRight):parseFloat(t.paddingTop)+parseFloat(t.paddingBottom)}(R);if(null===t)return e;if(N.reduce((function(e,t){return e+t}),0)>t)return e;var i=0,s=[],n=e.map((function(n,r){var o=t*n/100,a=E(M,0===r,r===e.length-1,P),l=N[r]+a;return o0&&s[n]-i>0){var o=Math.min(i,s[n]-i);i-=o,r=e-o}return r/t*100}))}function Z(){var e=this,i=v[e.a].element,s=v[e.b].element;e.dragging&&b(t,"onDragEnd",f)(K()),e.dragging=!1,o[h]("mouseup",e.stop),o[h]("touchend",e.stop),o[h]("touchcancel",e.stop),o[h]("mousemove",e.move),o[h]("touchmove",e.move),e.stop=null,e.move=null,i[h]("selectstart",f),i[h]("dragstart",f),s[h]("selectstart",f),s[h]("dragstart",f),i.style.userSelect="",i.style.webkitUserSelect="",i.style.MozUserSelect="",i.style.pointerEvents="",s.style.userSelect="",s.style.webkitUserSelect="",s.style.MozUserSelect="",s.style.pointerEvents="",e.gutter.style.cursor="",e.parent.style.cursor="",l.body.style.cursor=""}function J(e){if(!("button"in e)||0===e.button){var i=this,s=v[i.a].element,n=v[i.b].element;i.dragging||b(t,"onDragStart",f)(K()),e.preventDefault(),i.dragging=!0,i.move=$.bind(i),i.stop=Z.bind(i),o[c]("mouseup",i.stop),o[c]("touchend",i.stop),o[c]("touchcancel",i.stop),o[c]("mousemove",i.move),o[c]("touchmove",i.move),s[c]("selectstart",f),s[c]("dragstart",f),n[c]("selectstart",f),n[c]("dragstart",f),s.style.userSelect="none",s.style.webkitUserSelect="none",s.style.MozUserSelect="none",s.style.pointerEvents="none",n.style.userSelect="none",n.style.webkitUserSelect="none",n.style.MozUserSelect="none",n.style.pointerEvents="none",i.gutter.style.cursor=W,i.parent.style.cursor=W,l.body.style.cursor=W,Q.call(i),i.dragOffset=Y(e)-i.end}}B===m?(i="width",s="clientX",n="left",r="right",_="clientWidth"):"vertical"===B&&(i="height",s="clientY",n="top",r="bottom",_="clientHeight"),k=X(k);var ee=[];function te(e){var t=e.i===ee.length,i=t?ee[e.i-1]:ee[e.i];Q.call(i);var s=t?i.size-e.minSize-i[p]:e.minSize+i[g];q.call(i,s)}return(v=L.map((function(e,t){var s,n={element:C(e),size:k[t],minSize:N[t],maxSize:O[t],snapOffset:U[t],i:t};if(t>0&&((s={a:t-1,b:t,dragging:!1,direction:B,parent:R})[g]=E(M,t-1===0,!1,P),s[p]=E(M,!1,t===L.length-1,P),"row-reverse"===x||"column-reverse"===x)){var r=s.a;s.a=s.b,s.b=r}if(t>0){var o=V(t,B,n.element);!function(e,t,s){var n=G(i,t,s);Object.keys(n).forEach((function(t){e.style[t]=n[t]}))}(o,M,t),s[u]=J.bind(s),o[c]("mousedown",s[u]),o[c]("touchstart",s[u]),R.insertBefore(o,n.element),s.gutter=o}return j(n.element,n.size,E(M,0===t,t===L.length-1,P),t),t>0&&ee.push(s),n}))).forEach((function(e){var t=e.element[d]()[i];t0){var s=ee[i-1],n=v[s.a],r=v[s.b];n.size=t[i-1],r.size=e,j(n.element,n.size,s[g],n.i),j(r.element,r.size,s[p],r.i)}}))},getSizes:K,collapse:function(e){te(v[e])},destroy:function(e,t){ee.forEach((function(s){if(!0!==t?s.parent.removeChild(s.gutter):(s.gutter[h]("mousedown",s[u]),s.gutter[h]("touchstart",s[u])),!0!==e){var n=z(i,s.a.size,s[g]);Object.keys(n).forEach((function(e){v[s.a].element.style[e]="",v[s.b].element.style[e]=""}))}}))},parent:R,pairs:ee}};function R(e,t){var i={};for(var s in e)Object.prototype.hasOwnProperty.call(e,s)&&-1===t.indexOf(s)&&(i[s]=e[s]);return i}var T=function(e){function t(){e.apply(this,arguments)}return e&&(t.__proto__=e),t.prototype=Object.create(e&&e.prototype),t.prototype.constructor=t,t.prototype.componentDidMount=function(){var e=this.props;e.children;var t=e.gutter,i=R(e,["children","gutter"]);i.gutter=function(e,i){var s;return t?s=t(e,i):(s=document.createElement("div")).className="gutter gutter-"+i,s.__isSplitGutter=!0,s},this.split=L(this.parent.children,i)},t.prototype.componentDidUpdate=function(e){var t=this,i=this.props;i.children;var s=i.minSize,n=i.sizes,r=i.collapsed,o=R(i,["children","minSize","sizes","collapsed"]),a=e.minSize,l=e.sizes,c=e.collapsed,h=["maxSize","expandToMin","gutterSize","gutterAlign","snapOffset","dragInterval","direction","cursor"].map((function(i){return t.props[i]!==e[i]})).reduce((function(e,t){return e||t}),!1);if(Array.isArray(s)&&Array.isArray(a)){var d=!1;s.forEach((function(e,t){d=d||e!==a[t]})),h=h||d}else h=!(!Array.isArray(s)&&!Array.isArray(a))||(h||s!==a);if(h)o.minSize=s,o.sizes=n||this.split.getSizes(),this.split.destroy(!0,!0),o.gutter=function(e,t,i){return i.previousSibling},this.split=L(Array.from(this.parent.children).filter((function(e){return!e.__isSplitGutter})),o);else if(n){var u=!1;n.forEach((function(e,t){u=u||e!==l[t]})),u&&this.split.setSizes(this.props.sizes)}Number.isInteger(r)&&(r!==c||h)&&this.split.collapse(r)},t.prototype.componentWillUnmount=function(){this.split.destroy(),delete this.split},t.prototype.render=function(){var e=this,t=this.props;t.sizes,t.minSize,t.maxSize,t.expandToMin,t.gutterSize,t.gutterAlign,t.snapOffset,t.dragInterval,t.direction,t.cursor,t.gutter,t.elementStyle,t.gutterStyle,t.onDrag,t.onDragStart,t.onDragEnd,t.collapsed;var i=t.children,n=R(t,["sizes","minSize","maxSize","expandToMin","gutterSize","gutterAlign","snapOffset","dragInterval","direction","cursor","gutter","elementStyle","gutterStyle","onDrag","onDragStart","onDragEnd","collapsed","children"]);return s.createElement("div",Object.assign({},{ref:function(t){e.parent=t}},n),i)},t}(s.Component);T.propTypes={sizes:r().arrayOf(r().number),minSize:r().oneOfType([r().number,r().arrayOf(r().number)]),maxSize:r().oneOfType([r().number,r().arrayOf(r().number)]),expandToMin:r().bool,gutterSize:r().number,gutterAlign:r().string,snapOffset:r().oneOfType([r().number,r().arrayOf(r().number)]),dragInterval:r().number,direction:r().string,cursor:r().string,gutter:r().func,elementStyle:r().func,gutterStyle:r().func,onDrag:r().func,onDragStart:r().func,onDragEnd:r().func,collapsed:r().number,children:r().arrayOf(r().element)},T.defaultProps={sizes:void 0,minSize:void 0,maxSize:void 0,expandToMin:void 0,gutterSize:void 0,gutterAlign:void 0,snapOffset:void 0,dragInterval:void 0,direction:void 0,cursor:void 0,gutter:void 0,elementStyle:void 0,gutterStyle:void 0,onDrag:void 0,onDragStart:void 0,onDragEnd:void 0,collapsed:void 0,children:void 0};const x=T},72093:(e,t,i)=>{"use strict";i.d(t,{A:()=>h});const s={randomUUID:"undefined"!==typeof crypto&&crypto.randomUUID&&crypto.randomUUID.bind(crypto)};var n,r=new Uint8Array(16);function o(){if(!n&&!(n="undefined"!==typeof crypto&&crypto.getRandomValues&&crypto.getRandomValues.bind(crypto)))throw new Error("crypto.getRandomValues() not supported. See https://github.com/uuidjs/uuid#getrandomvalues-not-supported");return n(r)}for(var a=[],l=0;l<256;++l)a.push((l+256).toString(16).slice(1));function c(e,t=0){return(a[e[t+0]]+a[e[t+1]]+a[e[t+2]]+a[e[t+3]]+"-"+a[e[t+4]]+a[e[t+5]]+"-"+a[e[t+6]]+a[e[t+7]]+"-"+a[e[t+8]]+a[e[t+9]]+"-"+a[e[t+10]]+a[e[t+11]]+a[e[t+12]]+a[e[t+13]]+a[e[t+14]]+a[e[t+15]]).toLowerCase()}const h=function(e,t,i){if(s.randomUUID&&!t&&!e)return s.randomUUID();var n=(e=e||{}).random||(e.rng||o)();if(n[6]=15&n[6]|64,n[8]=63&n[8]|128,t){i=i||0;for(var r=0;r<16;++r)t[i+r]=n[r];return t}return c(n)}},57949:(e,t,i)=>{"use strict";i.d(t,{F:()=>B});var s=i(60712),n=i(59284),r=i(56993),o=i.n(r),a=i(53302),l=i(63126),c=i(72837);const h=JSON.parse('{"label_error":"Error","label_empty":"No data"}'),d=JSON.parse('{"label_error":"\u041e\u0448\u0438\u0431\u043a\u0430","label_empty":"\u041d\u0435\u0442 \u0434\u0430\u043d\u043d\u044b\u0445"}'),u=(0,c.N)({en:h,ru:d},"ydb-navigation-tree"),g=(0,a.o)("ydb-navigation-tree-view-empty");function p({level:e}){return(0,s.jsx)(l.G,{name:(0,s.jsx)("span",{className:g(),children:u("label_empty")}),level:e})}const m=(0,a.o)("ydb-navigation-tree-view-error");function f({level:e}){return(0,s.jsx)(l.G,{name:(0,s.jsx)("span",{className:m(),children:u("label_error")}),level:e})}var _=i(80953);const v=(0,a.o)("ydb-navigation-tree-view-loader");function C({level:e}){return(0,s.jsx)(l.G,{name:(0,s.jsx)("div",{className:v(),children:(0,s.jsx)(_.t,{size:"xs"})}),level:e})}function b(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M9.22 15.03s-.001 0 0 0a.75.75 0 0 0 1.06-1.06l-.47-.47H10a3.016 3.016 0 0 0 1.507-.405A2.999 2.999 0 0 0 13 10.5V7.896h.003a2.735 2.735 0 0 0 .785-.366 2.75 2.75 0 1 0-2.288.366V10.5A1.5 1.5 0 0 1 10 12h-.19l.47-.47s0 .001 0 0a.75.75 0 0 0-1.06-1.06l-.47.47-1.28 1.28a.75.75 0 0 0 0 1.06l1.75 1.75ZM5.72 2.97a.75.75 0 0 1 1.06 0l.47.47 1.28 1.28a.748.748 0 0 1 0 1.06L6.78 7.53c.001 0 0 0 0 0a.751.751 0 0 1-1.06-1.06L6.19 6H6a1.5 1.5 0 0 0-1.5 1.5v2.604a2.757 2.757 0 0 1 2 2.646 2.738 2.738 0 0 1-1.212 2.28 2.737 2.737 0 0 1-1.538.47A2.747 2.747 0 0 1 1 12.75a2.751 2.751 0 0 1 2-2.646V7.5a2.999 2.999 0 0 1 3-3h.19l-.47-.47a.75.75 0 0 1 0-1.06Zm-.908 9.121A1.246 1.246 0 0 1 5 12.75a1.25 1.25 0 1 1-.188-.659ZM11 5.25a1.25 1.25 0 1 1 2.5 0 1.25 1.25 0 0 1-2.5 0Z"})}))}function E(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M2.01033 3.79551C2.11275 2.787 2.96447 2 4 2H5.5H7H9H10.5H12C13.1046 2 14 2.89543 14 4V5.5V12C14 13.1046 13.1046 14 12 14H10.5H9H7H5.5H4C2.89543 14 2 13.1046 2 12V5.5V4C2 3.93096 2.0035 3.86275 2.01033 3.79551ZM10.5 12.5H11.5C12.0523 12.5 12.5 12.0523 12.5 11.5V5.5H10.5L10.5 12.5ZM9 5.5L9 12.5H7L7 5.5H9ZM3.5 5.5H5.5L5.5 12.5H4.5C3.94772 12.5 3.5 12.0523 3.5 11.5V5.5Z"})}))}function S(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 448 512",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"M448 80V128C448 172.2 347.7 208 224 208C100.3 208 0 172.2 0 128V80C0 35.82 100.3 0 224 0C347.7 0 448 35.82 448 80zM393.2 214.7C413.1 207.3 433.1 197.8 448 186.1V288C448 332.2 347.7 368 224 368C100.3 368 0 332.2 0 288V186.1C14.93 197.8 34.02 207.3 54.85 214.7C99.66 230.7 159.5 240 224 240C288.5 240 348.3 230.7 393.2 214.7V214.7zM54.85 374.7C99.66 390.7 159.5 400 224 400C288.5 400 348.3 390.7 393.2 374.7C413.1 367.3 433.1 357.8 448 346.1V432C448 476.2 347.7 512 224 512C100.3 512 0 476.2 0 432V346.1C14.93 357.8 34.02 367.3 54.85 374.7z"})}))}function y(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M0 6.75C0 6.35156 0.338542 6 0.722222 6L3.61111 6V3L0.722222 3C0.338542 3 0 2.67188 0 2.25C0 1.85156 0.338542 1.5 0.722222 1.5L3.61111 1.5V0.750001C3.61111 0.351563 3.94965 0 4.33333 0C4.73958 0 5.05556 0.351563 5.05556 0.750001H5.77778C7.53819 0.750001 8.98264 2.03906 9.32118 3.75H12V5.25H9.32118C9.29095 5.4049 9.25189 5.55606 9.20457 5.70291C9.10459 5.73587 9.00778 5.77066 8.9144 5.80723C8.505 5.96755 8.12646 6.17556 7.83841 6.44187C7.5498 6.70871 7.3 7.08678 7.3 7.56255V7.90902C6.83862 8.12843 6.32337 8.25 5.77778 8.25H5.05556C5.05556 8.67188 4.73958 9 4.33333 9C3.94965 9 3.61111 8.67188 3.61111 8.25V7.5L0.722222 7.5C0.338542 7.5 0 7.17188 0 6.75ZM16 8.5V7.5625C16 6.70312 14.1964 6 12 6C9.78571 6 8 6.70312 8 7.5625V8.5C8 9.37891 9.78571 10.0625 12 10.0625C14.1964 10.0625 16 9.37891 16 8.5ZM16 9.65234C15.7321 9.86719 15.375 10.0625 15.0179 10.1992C14.2143 10.5117 13.1429 10.6875 12 10.6875C10.8393 10.6875 9.76786 10.5117 8.96429 10.1992C8.60714 10.0625 8.25 9.86719 8 9.65234V11.625C8 12.5039 9.78571 13.1875 12 13.1875C14.1964 13.1875 16 12.5039 16 11.625V9.65234ZM12 13.8125C10.8393 13.8125 9.76786 13.6367 8.96429 13.3242C8.60714 13.1875 8.25 12.9922 8 12.7773V14.4375C8 15.3164 9.78571 16 12 16C14.1964 16 16 15.3164 16 14.4375V12.7773C15.7321 12.9922 15.375 13.1875 15.0179 13.3242C14.2143 13.6367 13.1429 13.8125 12 13.8125Z"})}))}function w(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M0 6.75C0 6.35156 0.351562 6 0.75 6L3.75 6V3L0.75 3C0.351562 3 0 2.67188 0 2.25C0 1.85156 0.351562 1.5 0.75 1.5L3.75 1.5V0.750001C3.75 0.351563 4.10156 0 4.5 0C4.92188 0 5.25 0.351563 5.25 0.750001H6C7.82812 0.750001 9.32812 2.03906 9.67969 3.75H12V5.25H9.67969C9.60376 5.62455 9.47428 5.97724 9.2995 6.30005H7.19969C6.09701 6.30005 5.26846 7.20143 5.25 8.25C5.25 8.67188 4.92188 9 4.5 9C4.10156 9 3.75 8.67188 3.75 8.25V7.5L0.75 7.5C0.351562 7.5 0 7.17188 0 6.75ZM16 8.28571C16 7.58259 15.4336 7 14.75 7H7.25C6.54688 7 6 7.58259 6 8.28571V14.7143C6 15.4375 6.54688 16 7.25 16H14.75C15.4336 16 16 15.4375 16 14.7143V8.28571ZM10.375 9.57143V11.5H7.25V9.57143H10.375ZM7.25 14.7143V12.7857H10.375V14.7143H7.25ZM14.75 14.7143H11.625V12.7857H14.75V14.7143ZM14.75 9.57143V11.5H11.625V9.57143H14.75Z"})}))}function L(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"M13.2812 4.875H8.40625L6.78125 3.25H2.71875C2.0332 3.25 1.5 3.80859 1.5 4.46875V11.7812C1.5 12.4668 2.0332 13 2.71875 13H13.2812C13.9414 13 14.5 12.4668 14.5 11.7812V6.09375C14.5 5.43359 13.9414 4.875 13.2812 4.875Z"})}))}function R(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{d:"M15.2109 9.06445C15.4648 8.6582 15.1602 8.125 14.6777 8.125H4.54688C4.01367 8.125 3.37891 8.50586 3.125 8.9375L1.29688 12.0859C1.04297 12.4922 1.34766 13 1.83008 13H11.9609C12.4941 13 13.1289 12.6445 13.3828 12.2129L15.2109 9.06445ZM4.54688 7.3125H12.875V6.09375C12.875 5.43359 12.3164 4.875 11.6562 4.875H7.59375L5.96875 3.25H1.90625C1.2207 3.25 0.6875 3.80859 0.6875 4.46875V11.5527L2.43945 8.53125C2.87109 7.79492 3.6582 7.3125 4.54688 7.3125Z"})}))}function T(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M9.24935 2.94323L8.5 9.5H12.1L11.1446 14.2772C11.0322 14.839 11.7994 15.1177 12.0738 14.6147L15.9111 7.57956C16.1765 7.09311 15.8244 6.5 15.2703 6.5H12.9L13.5325 3.33728C13.6192 2.90413 13.2879 2.5 12.8461 2.5H9.74611C9.49194 2.5 9.27821 2.69069 9.24935 2.94323ZM7.40003 10.5L8.25717 3H1.625C0.710938 3 0 3.73633 0 4.625V12.75C0 13.6641 0.710938 14.375 1.625 14.375H10.1517C10.1538 14.2803 10.1646 14.1822 10.1848 14.0811L10.901 10.5H7.40003ZM5.6875 8.6875V6.25H1.625V8.6875H5.6875ZM1.625 10.3125V12.75H5.6875V10.3125H1.625Z"})}))}function x(e){return(0,s.jsx)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M2.01033 3.79551C2.11275 2.787 2.96447 2 4 2H7.3H8.8H12C13.1046 2 14 2.89543 14 4V5.5V8.2002V9.7002V12C14 13.1046 13.1046 14 12 14H8.8H7.3H4C2.89543 14 2 13.1046 2 12V9.7002V8.2002V5.5V4C2 3.93096 2.0035 3.86275 2.01033 3.79551ZM8.8 12.5H11.5C12.0523 12.5 12.5 12.0523 12.5 11.5V9.7002H8.8V12.5ZM7.3 9.7002V12.5H4.5C3.94772 12.5 3.5 12.0523 3.5 11.5V9.7002H7.3ZM8.8 8.2002H12.5V5.5H8.8L8.8 8.2002ZM7.3 5.5L7.3 8.2002H3.5V5.5H7.3Z"})}))}function k(e){return(0,s.jsxs)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:[(0,s.jsx)("rect",{x:"2",y:"2.20001",width:"9",height:"2.5",rx:"0.5"}),(0,s.jsx)("rect",{x:"5",y:"6.70001",width:"9",height:"2.5",rx:"0.5"}),(0,s.jsx)("rect",{x:"2",y:"11.2",width:"9",height:"2.5",rx:"0.5"})]}))}function A(e){return(0,s.jsxs)("svg",Object.assign({xmlns:"http://www.w3.org/2000/svg",viewBox:"0 0 16 16",fill:"currentColor"},e,{children:[(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M1.625 2H7.49951C6.47457 2.77006 5.7552 3.92488 5.55588 5.25H1.625V7.6875H5.79193C6.48417 9.6186 8.33076 11 10.5 11C10.877 11 11.2443 10.9583 11.5974 10.8792L12.7748 12.5799C12.4905 13.0601 11.9665 13.375 11.375 13.375H1.625C0.710938 13.375 0 12.6641 0 11.75V3.625C0 2.73633 0.710938 2 1.625 2ZM1.625 11.75V9.3125H5.6875V11.75H1.625Z"}),(0,s.jsx)("path",{fillRule:"evenodd",clipRule:"evenodd",d:"M13.4411 8.71106C14.0985 7.9983 14.5 7.04604 14.5 6C14.5 3.79086 12.7091 2 10.5 2C8.29086 2 6.5 3.79086 6.5 6C6.5 8.20914 8.29086 10 10.5 10C11.0316 10 11.5389 9.89631 12.0029 9.70806L14.2807 12.9981C14.5557 13.3955 15.1008 13.4946 15.4981 13.2195C15.8955 12.9444 15.9946 12.3993 15.7195 12.002L13.4411 8.71106ZM12.5 6C12.5 7.10457 11.6046 8 10.5 8C9.39543 8 8.5 7.10457 8.5 6C8.5 4.89543 9.39543 4 10.5 4C11.6046 4 12.5 4.89543 12.5 6Z"})]}))}function N(e){return"status"in e}function I(e,t,i,s=0){const n=e[t];if(n&&(i(n,s,t,e),!n.collapsed))for(const r of n.children)I(e,`${t}/${r}`,i,s+1)}var O;function D(e){return Object.assign(Object.assign(Object.assign({},{collapsed:!0,loading:!1,loaded:!1,error:!1,children:[]}),{expandable:"database"===e.type||"directory"===e.type}),e)}function M(e={},t){var i,s;switch(t.type){case O.ToggleCollapsed:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{collapsed:!e[t.payload.path].collapsed})});case O.StartLoading:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{loading:!0,loaded:!1,error:!1,children:[]})});case O.FinishLoading:{const n=Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{loading:!1,loaded:Boolean(t.payload.data),error:!1})});if(t.payload.data){n[t.payload.path].children=t.payload.data.map((({name:e})=>e));for(const r of t.payload.data){const o=`${t.payload.path}/${r.name}`,{activePath:a=""}=t.payload,l=null!==(s=null===(i=e[o])||void 0===i?void 0:i.collapsed)&&void 0!==s?s:!a.startsWith(`${o}/`);n[o]=D(Object.assign(Object.assign({},r),{collapsed:l,path:o}))}}return t.payload.data&&0!==t.payload.data.length||(n[t.payload.path]=Object.assign(Object.assign({},n[t.payload.path]),{expandable:!1,collapsed:!0})),n}case O.ErrorLoading:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{loading:!1,loaded:!1,error:!0})});case O.ResetNode:return Object.assign(Object.assign({},e),{[t.payload.path]:Object.assign(Object.assign({},e[t.payload.path]),{collapsed:!0,loading:!1,loaded:!1,error:!1,children:[]})});default:return e}}function P(e,t){const i=[];return I(e,t,((e,t)=>{i.push(Object.assign(Object.assign({},e),{level:t}));const s=function(e,t){if(!e.collapsed)return e.loading?{path:e.path,status:"loading",level:t+1}:e.error?{path:e.path,status:"error",level:t+1}:e.loaded&&0===e.children.length?{path:e.path,status:"empty",level:t+1}:void 0}(e,t);s&&i.push(s)})),i}function F(e,t){switch(e){case"async_replication":return(0,s.jsx)(b,{height:16});case"database":return(0,s.jsx)(S,{height:14});case"directory":return t?(0,s.jsx)(L,{height:16}):(0,s.jsx)(R,{height:16});case"index":return(0,s.jsx)(T,{height:16});case"table":case"index_table":return(0,s.jsx)(x,{height:16});case"column_table":return(0,s.jsx)(E,{height:16});case"stream":case"topic":return(0,s.jsx)(k,{height:16});case"external_table":return(0,s.jsx)(w,{height:16});case"external_data_source":return(0,s.jsx)(y,{height:16});case"view":return(0,s.jsx)(A,{height:16});default:return null}}function U({path:e,fetchPath:t,activePath:i,state:r,level:o,dispatch:a,children:c,onActivate:h,getActions:d,onActionsOpenToggle:u,renderAdditionalNodeElements:g,cache:p}){const m=r[e];n.useEffect((()=>{m.collapsed?p||a({type:O.ResetNode,payload:{path:e}}):m.loaded||m.loading||(a({type:O.StartLoading,payload:{path:e}}),t(e).then((t=>{a({type:O.FinishLoading,payload:{path:e,activePath:i,data:t}})})).catch((t=>{a({type:O.ErrorLoading,payload:{path:e,error:t}})})))}),[m.collapsed]);const f=n.useCallback((()=>{h&&h(e)}),[e,h]),_=n.useCallback((()=>{a({type:O.ToggleCollapsed,payload:{path:e}})}),[a,e]),v=n.useMemo((()=>null===g||void 0===g?void 0:g(m.path,m.type)),[g,m]),C=n.useMemo((()=>null===d||void 0===d?void 0:d(m.path,m.type)),[d,m]),b=n.useCallback((e=>{null===u||void 0===u||u({path:m.path,type:m.type,isOpen:e})}),[m.path,m.type,u]);return(0,s.jsx)(l.G,{name:m.name,icon:F(m.type,m.collapsed),collapsed:m.collapsed,active:m.path===i,actions:C,additionalNodeElements:v,hasArrow:m.expandable,onClick:f,onArrowClick:_,onActionsOpenToggle:b,level:o,children:c})}!function(e){e.ToggleCollapsed="toggle-collapsed",e.StartLoading="start-loading",e.FinishLoading="finish-loading",e.ErrorLoading="error-loading",e.ResetNode="reset-node"}(O||(O={}));const H=e=>{const t=`${e.path}|${e.status}`;return"loading"===e.status?(0,s.jsx)(C,{level:e.level},t):"error"===e.status?(0,s.jsx)(f,{level:e.level},t):(0,s.jsx)(p,{level:e.level},t)};function B({rootState:e,fetchPath:t,getActions:i,renderAdditionalNodeElements:r,activePath:a,onActionsOpenToggle:l,onActivePathUpdate:c,cache:h=!0,virtualize:d=!1}){const[u,g]=n.useReducer(M,{[e.path]:D(e)}),p=n.useMemo((()=>P(u,e.path)),[e.path,u]),m=e=>(0,s.jsx)(U,{state:u,path:e.path,activePath:a,fetchPath:t,dispatch:g,onActivate:c,getActions:i,onActionsOpenToggle:l,renderAdditionalNodeElements:r,cache:h,level:e.level},e.path);return d?(0,s.jsx)(o(),{type:"uniform",length:p.length,useStaticSize:!0,itemRenderer:e=>{const t=p[e];return N(t)?H(t):m(t)}}):(0,s.jsx)(n.Fragment,{children:p.map((e=>N(e)?H(e):m(e)))})}},63126:(e,t,i)=>{"use strict";i.d(t,{G:()=>c});var s=i(60712),n=i(59284),r=i(40569),o=i(53302);const a="--ydb-tree-view-level",l=(0,o.o)("ydb-tree-view");function c({children:e,name:t,title:i,icon:o,collapsed:c=!0,active:h=!1,onClick:d,onArrowClick:u,onActionsOpenToggle:g,hasArrow:p=!1,actions:m,additionalNodeElements:f,level:_}){const v=n.useCallback((e=>{if(!d)return;e.nativeEvent.composedPath().some((e=>e instanceof HTMLElement&&("BUTTON"===e.nodeName&&!e.hasAttribute("disabled")||e.hasAttribute("tabindex")&&e.tabIndex>-1)))||d()}),[d]),C=u||d;let b="tree-view_arrow",E="tree-view_children";return c&&(b+=" tree-view_arrow-collapsed",E+=" tree-view_children-collapsed"),(0,s.jsx)("div",{className:l(),style:{[a]:_},children:(0,s.jsxs)("div",{className:"tree-view",children:[(0,s.jsxs)("div",{className:`tree-view_item ${l("item",{active:h})}`,onClick:v,children:[(0,s.jsx)("button",{type:"button",className:`${b} ${l("arrow",{collapsed:c,hidden:!p})}`,disabled:!C,onClick:C}),(0,s.jsxs)("div",{className:l("content"),children:[o&&(0,s.jsx)("div",{className:l("icon"),children:o}),(0,s.jsx)("div",{className:l("text"),title:i,children:t}),m&&m.length>0&&(0,s.jsxs)("div",{className:l("actions"),children:[f,(0,s.jsx)(r.r,{onOpenToggle:g,defaultSwitcherProps:{view:"flat-secondary",size:"s",pin:"brick-brick"},items:m})]})]})]}),(0,s.jsx)("div",{className:`${E} ${l("container",{collapsed:c})}`,children:c?null:e})]})})}},53302:(e,t,i)=>{"use strict";i.d(t,{o:()=>s});const s=(0,i(82435).withNaming)({e:"__",m:"_"})},62469:()=>{},10713:()=>{},48215:()=>{},53396:()=>{},82320:()=>{},91434:()=>{},41614:(e,t,i)=>{"use strict";i.d(t,{parseYqlQuery:()=>fu,kh:()=>mu});var s,n,r,o,a=Object.defineProperty,l=(e,t)=>a(e,"name",{value:t,configurable:!0});(n=s||(s={})).EOF=-1,n.UNKNOWN_SOURCE_NAME="",(o=r||(r={})).INVALID_TYPE=0,o.EPSILON=-2,o.MIN_USER_TOKEN_TYPE=1,o.EOF=s.EOF,o.DEFAULT_CHANNEL=0,o.HIDDEN_CHANNEL=1,o.MIN_USER_CHANNEL_VALUE=2;var c=l((e=>{const t=e;return void 0!==t.tokenSource&&void 0!==t.channel}),"isToken"),h=class{static{l(this,"BitSet")}data;constructor(e){this.data=e?new Uint32Array(e.map((e=>e>>>0))):new Uint32Array(1)}[Symbol.iterator](){const e=this.data.length;let t=0,i=this.data[t];const s=this.data;return{[Symbol.iterator](){return this},next:l((()=>{for(;t>>5]&=~(1<>>5;return!(t>=this.data.length)&&0!==(this.data[t]&1<=e)return t}set(e){if(e<0)throw new RangeError("index cannot be negative");this.resize(e),this.data[e>>>5]|=1<>>5;if(t<=this.data.length)return;const i=new Uint32Array(t);i.set(this.data),i.fill(0,this.data.length),this.data=i}bitCount(e){return e=(e=(858993459&(e-=e>>1&1431655765))+(e>>2&858993459))+(e>>4)&252645135,e+=e>>8,63&(e+=e>>16)}},d=class e{static{l(this,"MurmurHash")}static defaultSeed=701;constructor(){}static initialize(t=e.defaultSeed){return t}static updateFromComparable(e,t){return this.update(e,t?.hashCode()??0)}static update(e,t){return t=(t=Math.imul(t,3432918353))<<15|t>>>17,e=(e^=t=Math.imul(t,461845907))<<13|e>>>19,e=Math.imul(e,5)+3864292196}static finish(e,t){return e^=4*t,e^=e>>>16,e=Math.imul(e,2246822507),e^=e>>>13,e=Math.imul(e,3266489909),e^=e>>>16}static hashCode(t,i){return e.finish(e.update(i??e.defaultSeed,t),1)}},u=class e{static{l(this,"ObjectEqualityComparator")}static instance=new e;hashCode(e){return null==e?0:e.hashCode()}equals(e,t){return null==e?null==t:e.equals(t)}},g=class e{static{l(this,"DefaultEqualityComparator")}static instance=new e;hashCode(e){return null==e?0:u.instance.hashCode(e)}equals(e,t){return null==e?null==t:"string"===typeof e||"number"===typeof e?e===t:u.instance.equals(e,t)}},p=class e{static{l(this,"HashSet")}static defaultLoadFactor=.75;static initialCapacity=16;comparator;buckets;threshold;itemCount=0;constructor(t,i=e.initialCapacity){if(t instanceof e){this.comparator=t.comparator,this.buckets=t.buckets.slice(0);for(let e=0;ethis.threshold&&this.expand();const t=this.getBucket(e);let i=this.buckets[t];if(!i)return i=[e],this.buckets[t]=i,++this.itemCount,e;for(const s of i)if(this.comparator.equals(s,e))return s;return i.push(e),++this.itemCount,e}get(e){if(null==e)return e;const t=this.getBucket(e),i=this.buckets[t];if(i)for(const s of i)if(this.comparator.equals(s,e))return s}remove(e){if(null==e)return!1;const t=this.getBucket(e),i=this.buckets[t];if(!i)return!1;for(let s=0;se.INTERVAL_POOL_MAX_VALUE?new e(t,i):(e.cache[t]||(e.cache[t]=new e(t,t)),e.cache[t])}equals(e){return this.start===e.start&&this.stop===e.stop}hashCode(){return this.cachedHashCode}startsBeforeDisjoint(e){return this.start=e.start}startsAfter(e){return this.start>e.start}startsAfterDisjoint(e){return this.start>e.stop}startsAfterNonDisjoint(e){return this.start>e.start&&this.start<=e.stop}disjoint(e){return this.startsBeforeDisjoint(e)||this.startsAfterDisjoint(e)}adjacent(e){return this.start===e.stop+1||this.stop===e.start-1}properlyContains(e){return e.start>=this.start&&e.stop<=this.stop}union(t){return e.of(Math.min(this.start,t.start),Math.max(this.stop,t.stop))}intersection(t){return e.of(Math.max(this.start,t.start),Math.min(this.stop,t.stop))}differenceNotProperlyContained(t){let i=null;return t.startsBeforeNonDisjoint(this)?i=e.of(Math.max(this.start,t.stop+1),this.stop):t.startsAfterNonDisjoint(this)&&(i=e.of(this.start,t.start-1)),i}toString(){return`${this.start}..${this.stop}`}get length(){return this.stop0){const t=n.codePointAt(0);if(39===t){s[e]=null;continue}if(t>=65&&t<=90){i[e]=null;continue}}i[e]=null,s[e]=null}}return new e(i,s,t)}getMaxTokenType(){return this.maxTokenType}getLiteralName(e){return e>=0&&e=0&&e=0&&ethis.addInterval(e)),this),this}complementWithVocabulary(t){const i=new e;return t?0===t.length?i:(i.addSet(t),i.subtract(this)):i}complement(t,i){const s=new e;return s.addInterval(new m(t,i)),s.subtract(this)}or(t){const i=new e;return i.addSet(this),t.forEach((e=>i.addSet(e))),i}and(t){if(0===t.length)return new e;const i=this.intervals,s=t.intervals;let n;const r=i.length,o=s.length;let a=0,l=0;for(;ae.stop){s++;continue}let o,a;r.start>e.start&&(o=new m(e.start,r.start-1)),r.stope))return!0;i=s-1}}return!1}removeRange(e){if(this.cachedHashCode=void 0,e.start===e.stop)this.removeOne(e.start);else if(null!==this.intervals){let t=0;for(const i of this.intervals){if(e.stop<=i.start)return;if(e.start>i.start&&e.stop=i.stop?(this.intervals.splice(t,1),t-=1):e.start1&&(t+="{");for(let i=0;i":t+=e?"'"+String.fromCodePoint(n)+"'":n:t+=e?"'"+String.fromCodePoint(n)+"'..'"+String.fromCodePoint(o)+"'":n+".."+o,i1&&(t+="}"),t}toStringWithVocabulary(e){if(0===this.intervals.length)return"{}";let t="";this.length>1&&(t+="{");for(let i=0;i":t+=this.elementName(e,n);else for(let i=n;i<=o;++i)i>n&&(t+=", "),t+=this.elementName(e,i);i1&&(t+="}"),t}toStringWithRuleNames(e){if(0===this.intervals.length)return"{}";let t="";this.length>1&&(t+="{");const i=f.fromTokenNames(e);for(let s=0;s":t+=this.elementName(i,n);else for(let s=n;s<=o;++s)s>n&&(t+=", "),t+=this.elementName(i,s);s1&&(t+="}"),t}toArray(){const e=[];for(const t of this.intervals)for(let i=t.start;i<=t.stop;i++)e.push(i);return e}get length(){let e=0;for(const t of this.intervals)e+=t.length;return e}elementName(e,t){return t===r.EOF?"":t===r.EPSILON?"":e.getDisplayName(t)}},v=l((e=>null===e?"null":e),"valueToString"),C=l((e=>Array.isArray(e)?"["+e.map(v).join(", ")+"]":"null"),"arrayToString"),b=l(((e,t)=>{if(e===t)return!0;if(e.length!==t.length)return!1;for(let i=0;i{if(e===t)return!0;if(e.length!==t.length)return!1;for(let i=0;i(e=e.replace(/\t/g,"\\t").replace(/\n/g,"\\n").replace(/\r/g,"\\r"),t&&(e=e.replace(/ /g,"\xb7")),e)),"escapeWhitespace"),y=class e{static{l(this,"SemanticContext")}cachedHashCode;static andContext(t,i){if(null===t||t===e.NONE)return i;if(null===i||i===e.NONE)return t;const s=new w(t,i);return 1===s.operands.length?s.operands[0]:s}static orContext(t,i){if(null===t)return i;if(null===i)return t;if(t===e.NONE||i===e.NONE)return e.NONE;const s=new L(t,i);return 1===s.operands.length?s.operands[0]:s}static filterPrecedencePredicates(t){const i=[];for(const s of t)s instanceof e.PrecedencePredicate&&i.push(s);return i}evalPrecedence(e,t){return this}},w=class e extends y{static{l(this,"AND")}operands;constructor(t,i){super();const s=new p;t instanceof e?t.operands.forEach((e=>{s.add(e)})):s.add(t),i instanceof e?i.operands.forEach((e=>{s.add(e)})):s.add(i);const n=y.filterPrecedencePredicates(s);if(n.length>0){let e=null;n.forEach((t=>{(null===e||t.precedence{n=null===n?e:y.andContext(n,e)})),n}toString(){const e=this.operands.map((e=>e.toString()));return(e.length>3?e.slice(3):e).join("&&")}},L=class e extends y{static{l(this,"OR")}operands;constructor(t,i){super();const s=new p;t instanceof e?t.operands.forEach((e=>{s.add(e)})):s.add(t),i instanceof e?i.operands.forEach((e=>{s.add(e)})):s.add(i);const n=y.filterPrecedencePredicates(s);if(n.length>0){const e=n.sort(((e,t)=>e.compareTo(t))),t=e[e.length-1];s.add(t)}this.operands=s.toArray()}equals(t){return this===t||t instanceof e&&b(this.operands,t.operands)}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();for(const t of this.operands)e=d.updateFromComparable(e,t);e=d.update(e,3383313031),this.cachedHashCode=d.finish(e,this.operands.length+1)}return this.cachedHashCode}evaluate(e,t){for(const i of this.operands)if(i.evaluate(e,t))return!0;return!1}evalPrecedence(e,t){let i=!1;const s=[];for(const r of this.operands){const n=r.evalPrecedence(e,t);if(i||=n!==r,n===y.NONE)return y.NONE;null!==n&&s.push(n)}if(!i)return this;if(0===s.length)return null;let n=null;return s.forEach((e=>{n=null===n?e:y.orContext(n,e)})),n}toString(){const e=this.operands.map((e=>e.toString()));return(e.length>3?e.slice(3):e).join("||")}};(e=>{class t extends e{static{l(this,"Predicate")}ruleIndex;predIndex;isCtxDependent;constructor(e,t,i){super(),this.ruleIndex=e??-1,this.predIndex=t??-1,this.isCtxDependent=i??!1}evaluate(e,t){const i=this.isCtxDependent?t:null;return e.sempred(i,this.ruleIndex,this.predIndex)}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();e=d.update(e,this.ruleIndex),e=d.update(e,this.predIndex),e=d.update(e,this.isCtxDependent?1:0),e=d.finish(e,3),this.cachedHashCode=e}return this.cachedHashCode}equals(e){return this===e||this.ruleIndex===e.ruleIndex&&this.predIndex===e.predIndex&&this.isCtxDependent===e.isCtxDependent}toString(){return"{"+this.ruleIndex+":"+this.predIndex+"}?"}}e.Predicate=t;class i extends e{static{l(this,"PrecedencePredicate")}precedence;constructor(e){super(),this.precedence=e??0}evaluate(e,t){return e.precpred(t,this.precedence)}evalPrecedence(t,i){return t.precpred(i??null,this.precedence)?e.NONE:null}compareTo(e){return this.precedence-e.precedence}hashCode(){return 31+this.precedence}equals(e){return this===e||this.precedence===e.precedence}toString(){return"{"+this.precedence+">=prec}?"}}e.PrecedencePredicate=i,e.NONE=new t})(y||(y={}));var R,T=class e{static{l(this,"ATNConfig")}state;alt;reachesIntoOuterContext=!1;precedenceFilterSuppressed=!1;get semanticContext(){return this.#e}cachedHashCode;#t=null;#e;constructor(e,t,i,s){this.state=t,this.alt=e.alt,this.context=i,this.#e=s??y.NONE,this.reachesIntoOuterContext=e.reachesIntoOuterContext,void 0!==e.precedenceFilterSuppressed&&(this.precedenceFilterSuppressed=e.precedenceFilterSuppressed)}static duplicate(t,i){return new e(t,t.state,t.context,i??t.semanticContext)}static createWithContext(t,i,s,n){return new e({alt:i},t,s,n)}static createWithConfig(t,i,s){return new e(i,t,s??i.context,i.semanticContext)}static createWithSemanticContext(t,i,s){return new e(i,t??i.state,i.context,s)}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize(7);e=d.update(e,this.state.stateNumber),e=d.update(e,this.alt),e=d.updateFromComparable(e,this.#t),e=d.updateFromComparable(e,this.semanticContext),e=d.finish(e,4),this.cachedHashCode=e}return this.cachedHashCode}get context(){return this.#t}set context(e){this.#t=e,this.cachedHashCode=void 0}equals(e){return this===e||this.state.stateNumber===e.state.stateNumber&&this.alt===e.alt&&(null===this.context?null===e.context:this.context.equals(e.context))&&this.semanticContext.equals(e.semanticContext)&&this.precedenceFilterSuppressed===e.precedenceFilterSuppressed}toString(e,t=!0){let i="";return t&&(i=","+this.alt),"("+this.state+i+(null!==this.context?",["+this.context.toString()+"]":"")+(this.semanticContext!==y.NONE?","+this.semanticContext.toString():"")+(this.reachesIntoOuterContext?",up="+this.reachesIntoOuterContext:"")+")"}},x=class e{static{l(this,"ATNState")}static INVALID_STATE_NUMBER=-1;static INVALID_TYPE=0;static BASIC=1;static RULE_START=2;static BLOCK_START=3;static PLUS_BLOCK_START=4;static STAR_BLOCK_START=5;static TOKEN_START=6;static RULE_STOP=7;static BLOCK_END=8;static STAR_LOOP_BACK=9;static STAR_LOOP_ENTRY=10;static PLUS_LOOP_BACK=11;static LOOP_END=12;static stateType=e.INVALID_STATE_NUMBER;stateNumber=0;ruleIndex=0;epsilonOnlyTransitions=!1;nextTokenWithinRule;transitions=[];hashCode(){return this.stateNumber}equals(e){return this.stateNumber===e.stateNumber}toString(){return`${this.stateNumber}`}addTransitionAtIndex(e,t){0===this.transitions.length?this.epsilonOnlyTransitions=t.isEpsilon:this.epsilonOnlyTransitions!==t.isEpsilon&&(this.epsilonOnlyTransitions=!1),this.transitions.splice(e,1,t)}addTransition(e){0===this.transitions.length?this.epsilonOnlyTransitions=e.isEpsilon:this.epsilonOnlyTransitions!==e.isEpsilon&&(this.epsilonOnlyTransitions=!1),this.transitions.push(e)}setTransition(e,t){this.transitions.splice(e,1,t)}removeTransition(e){return this.transitions.splice(e,1)[0]}},k=class e{static{l(this,"PredictionContext")}static EMPTY_RETURN_STATE=2147483647;static traceATNSimulator=!1;cachedHashCode;constructor(e){this.cachedHashCode=e}static calculateEmptyHashCode(){let e=d.initialize(31);return e=d.finish(e,0),e}static calculateHashCodeSingle(e,t){let i=d.initialize(31);return i=d.updateFromComparable(i,e),i=d.update(i,t),i=d.finish(i,2),i}static calculateHashCodeList(e,t){let i=d.initialize(31);for(const s of e)i=d.updateFromComparable(i,s);for(const s of t)i=d.update(i,s);return i=d.finish(i,2*e.length),i}isEmpty(){return!1}hasEmptyPath(){return this.getReturnState(this.length-1)===e.EMPTY_RETURN_STATE}hashCode(){return this.cachedHashCode}toString(e){return""}},A=class e extends k{static{l(this,"SingletonPredictionContext")}parent;returnState;constructor(e,t){super(e?k.calculateHashCodeSingle(e,t):k.calculateEmptyHashCode()),this.parent=e??null,this.returnState=t}getParent(e){return this.parent}getReturnState(e){return this.returnState}equals(t){return this===t||t instanceof e&&(this.hashCode()===t.hashCode()&&(this.returnState===t.returnState&&(null==this.parent?null==t.parent:this.parent.equals(t.parent))))}toString(){const e=null===this.parent?"":this.parent.toString();return 0===e.length?this.returnState===k.EMPTY_RETURN_STATE?"$":""+this.returnState:this.returnState+" "+e}get length(){return 1}},N=class e extends A{static{l(this,"EmptyPredictionContext")}static instance=new e;constructor(){super(void 0,k.EMPTY_RETURN_STATE)}isEmpty(){return!0}getParent(){return null}getReturnState(){return this.returnState}equals(e){return this===e}toString(){return"$"}},I=class{static{l(this,"Transition")}static INVALID=0;static EPSILON=1;static RANGE=2;static RULE=3;static PREDICATE=4;static ATOM=5;static ACTION=6;static SET=7;static NOT_SET=8;static WILDCARD=9;static PRECEDENCE=10;target;constructor(e){this.target=e}get isEpsilon(){return!1}get label(){return null}toString(){return""}},O=class extends I{static{l(this,"SetTransition")}set;constructor(e,t){super(e),this.set=t||_.of(r.INVALID_TYPE,r.INVALID_TYPE)}get transitionType(){return I.SET}get label(){return this.set}matches(e,t,i){return this.set.contains(e)}toString(){return this.set.toString()}},D=class extends O{static{l(this,"NotSetTransition")}get transitionType(){return I.NOT_SET}matches(e,t,i){return e>=t&&e<=i&&!super.matches(e,t,i)}toString(){return"~"+super.toString()}},M=class{static{l(this,"MapKeyEqualityComparator")}keyComparator;constructor(e){this.keyComparator=e}hashCode(e){return this.keyComparator.hashCode(e.key)}equals(e,t){return this.keyComparator.equals(e.key,t.key)}},P=class e{static{l(this,"HashMap")}backingStore;constructor(t){t instanceof e?this.backingStore=new p(t.backingStore):(t=t??g.instance,this.backingStore=new p(new M(t)))}clear(){this.backingStore.clear()}containsKey(e){return this.backingStore.contains({key:e})}get(e){const t=this.backingStore.get({key:e});if(t)return t.value}get isEmpty(){return this.backingStore.isEmpty}set(e,t){const i=this.backingStore.get({key:e,value:t});let s;return i?(s=i.value,i.value=t):this.backingStore.add({key:e,value:t}),s}setIfAbsent(e,t){const i=this.backingStore.get({key:e,value:t});let s;return i?s=i.value:this.backingStore.add({key:e,value:t}),s}keys(){return this.backingStore.toArray().map((e=>e.key))}values(){return this.backingStore.toArray().map((e=>e.value))}get size(){return this.backingStore.size}hashCode(){return this.backingStore.hashCode()}equals(e){return this.backingStore.equals(e.backingStore)}},F=class{static{l(this,"TerminalNode")}parent=null;symbol;constructor(e){this.symbol=e}getChild(e){return null}getSymbol(){return this.symbol}getPayload(){return this.symbol}getSourceInterval(){if(null===this.symbol)return m.INVALID_INTERVAL;const e=this.symbol.tokenIndex;return new m(e,e)}getChildCount(){return 0}accept(e){return e.visitTerminal(this)}getText(){return this.symbol?.text??""}toString(){return this.symbol?.type===r.EOF?"":this.symbol?.text??""}toStringTree(){return this.toString()}},U=class extends F{static{l(this,"ErrorNode")}accept(e){return e.visitErrorNode(this)}},H=class e{static{l(this,"CommonToken")}static EMPTY_SOURCE=[null,null];source;tokenIndex;start;stop;type;line;column;channel;#i;constructor(e){this.type=e.type,this.source=e.source,this.tokenIndex=e.tokenIndex??-1,this.line=e.line??0,this.column=e.column??-1,this.channel=e.channel??r.DEFAULT_CHANNEL,this.start=e.start??0,this.stop=e.stop??0,this.#i=e.text,void 0===e.line&&null!==e.source[0]&&(this.line=e.source[0].line),void 0===e.column&&null!==e.source[0]&&(this.column=e.source[0].column)}static fromToken(t){const i=[t.tokenSource,t.inputStream];return new e({type:t.type,line:t.line,tokenIndex:t.tokenIndex,column:t.column,channel:t.channel,start:t.start,stop:t.stop,text:t.text,source:i})}static fromType(t,i){return new e({type:t,text:i,source:e.EMPTY_SOURCE})}static fromSource(t,i,s,n,r){return new e({type:i,channel:s,start:n,stop:r,source:t})}get tokenSource(){return this.source[0]}get inputStream(){return this.source[1]}set inputStream(e){this.source[1]=e}clone(){return new e({source:this.source,type:this.type,channel:this.channel,start:this.start,stop:this.stop,tokenIndex:this.tokenIndex,line:this.line,column:this.column,text:this.#i})}toString(e){let t="";this.channel>0&&(t=",channel="+this.channel);let i=this.text;i?(i=i.replace(/\n/g,"\\n"),i=i.replace(/\r/g,"\\r"),i=i.replace(/\t/g,"\\t")):i="";let s=String(this.type);return e&&(s=e.vocabulary.getDisplayName(this.type)??""),"[@"+this.tokenIndex+","+this.start+":"+this.stop+"='"+i+"',<"+s+">"+t+","+this.line+":"+this.column+"]"}get text(){if(void 0!==this.#i)return this.#i;const e=this.inputStream;if(!e)return;const t=e.size;return this.start"}set text(e){this.#i=e}setText(e){this.#i=e}setType(e){this.type=e}setLine(e){this.line=e}setCharPositionInLine(e){this.column=e}setChannel(e){this.channel=e}setTokenIndex(e){this.tokenIndex=e}},B=class e{static{l(this,"Trees")}static toStringTree(t,i,s){i=i??null,s&&(i=s.ruleNames);let n=e.getNodeText(t,i);n=S(n,!1);const r=t.getChildCount();if(0===r)return n;let o="("+n+" ";r>0&&(n=e.toStringTree(t.getChild(0),i),o=o.concat(n));for(let a=1;a=e.start.tokenIndex&&(null===e.stop||i<=e.stop.tokenIndex)?e:null}static stripChildrenOutOfRange(e,t,i,s){if(null!==e)for(let n=0;ns)&&this.isAncestorOf(o,t)){const t=H.fromType(r.INVALID_TYPE,"...");e.children[n]=new F(t)}}}static doFindAllNodes(t,i,s,n){s&&t instanceof F?t.symbol?.type===i&&n.push(t):!s&&t instanceof W&&t.ruleIndex===i&&n.push(t);for(let r=0;r{e instanceof U&&(this.children.push(e),e.parent=this)}))}enterRule(e){}exitRule(e){}addChild(e){return this.children.push(e),e}removeLastChild(){this.children.pop()}addTokenNode(e){const t=new F(e);return this.children.push(t),t.parent=this,t}addErrorNode(e){return e.parent=this,this.children.push(e),e}getChild(e,t){if(e<0||e>=this.children.length)return null;if(!t)return this.children[e];for(const i of this.children)if(i instanceof t){if(0===e)return i;e-=1}return null}getToken(e,t){if(t<0||t>=this.children.length)return null;for(const i of this.children)if("symbol"in i&&i.symbol?.type===e){if(0===t)return i;t-=1}return null}getTokens(e){const t=[];for(const i of this.children)"symbol"in i&&i.symbol?.type===e&&t.push(i);return t}getRuleContext(e,t){return this.getChild(e,t)}getRuleContexts(e){const t=[];for(const i of this.children)i instanceof e&&t.push(i);return t}getChildCount(){return this.children.length}getSourceInterval(){return null===this.start?m.INVALID_INTERVAL:null===this.stop||this.stop.tokenIndexe.getText())).join("")}getAltNumber(){return Z.INVALID_ALT_NUMBER}setAltNumber(e){}accept(e){return e.visitChildren(this)}toStringTree(...e){return e.length<2?B.toStringTree(this,null,e[0]):B.toStringTree(this,e[0],e[1])}toString(e,t){e=e??null,t=t??null;let i=this,s="[";for(;null!==i&&i!==t;){if(null===e)i.isEmpty()||(s+=i.invokingState);else{const t=i.ruleIndex;s+=t>=0&&tt===k.EMPTY_RETURN_STATE&&null===e?N.instance:new A(e,t)),"createSingletonPredictionContext"),G=l(((e,t)=>{if(t||(t=W.empty),!t.parent||t===W.empty)return N.instance;const i=G(e,t.parent),s=e.states[t.invokingState].transitions[0];return z(i,s.followState.stateNumber)}),"predictionContextFromRuleContext"),j=l(((e,t,i)=>{if(e.isEmpty())return e;let s=i.get(e);if(s)return s;if(s=t.get(e),s)return i.set(e,s),s;let n,r=!1,o=[];for(let a=0;a{if(e===t||e.equals(t))return e;if(e instanceof A&&t instanceof A)return $(e,t,i,s);if(i){if(e instanceof N)return e;if(t instanceof N)return t}return e instanceof A&&(e=new V([e.parent],[e.returnState])),t instanceof A&&(t=new V([t.parent],[t.returnState])),Y(e,t,i,s)}),"merge"),Y=l(((e,t,i,s)=>{if(s){let i=s.get(e,t);if(i)return i;if(i=s.get(t,e),i)return i}let n=0,r=0,o=0,a=new Array(e.returnStates.length+t.returnStates.length).fill(0),l=new Array(e.returnStates.length+t.returnStates.length).fill(null);for(;n a"),e):c.equals(t)?(null!==s&&s.set(e,t,t),t):(q(l),null!==s&&s.set(e,t,c),k.traceATNSimulator&&console.log("mergeArrays a="+e+",b="+t+" -> "+c),c)}),"mergeArrays"),q=l((e=>{const t=new P(u.instance);for(const i of e)i&&(t.containsKey(i)||t.set(i,i));for(let i=0;i{if(null!==s){let i=s.get(e,t);if(null!==i)return i;if(i=s.get(t,e),null!==i)return i}const n=Q(e,t,i);if(null!==n)return null!==s&&s.set(e,t,n),n;if(e.returnState===t.returnState){const n=K(e.parent,t.parent,i,s);if(n===e.parent)return e;if(n===t.parent)return t;const r=z(n,e.returnState);return null!==s&&s.set(e,t,r),r}{let i=null;if((e===t||null!==e.parent&&e.parent.equals(t.parent))&&(i=e.parent),null!==i){const n=[e.returnState,t.returnState];e.returnState>t.returnState&&(n[0]=t.returnState,n[1]=e.returnState);const r=new V([i,i],n);return null!==s&&s.set(e,t,r),r}const n=[e.returnState,t.returnState];let r=[e.parent,t.parent];e.returnState>t.returnState&&(n[0]=t.returnState,n[1]=e.returnState,r=[t.parent,e.parent]);const o=new V(r,n);return null!==s&&s.set(e,t,o),o}}),"mergeSingletons"),Q=l(((e,t,i)=>{if(i){if(e===N.instance||t===N.instance)return N.instance}else{if(e===N.instance&&t===N.instance)return N.instance;if(e===N.instance){const e=[t.returnState,k.EMPTY_RETURN_STATE],i=[t.parent,null];return new V(i,e)}if(t===N.instance){const t=[e.returnState,k.EMPTY_RETURN_STATE],i=[e.parent,null];return new V(i,t)}}return null}),"mergeRoot"),X=class e{constructor(e){this.atn=e}static{l(this,"LL1Analyzer")}static hitPredicate=r.INVALID_TYPE;getDecisionLookahead(t){if(!t)return;const i=t.transitions.length,s=new Array(i);for(let n=0;n0&&!i.contains(e.hitPredicate)&&(s[n]=i)}return s}look(e,t,i){const s=new _,n=i?G(this.atn,i):null;return this.doLook(e,t,n,s,new p,new h,!0,!0),s}doLook(t,i,s,n,o,a,l,c){const h=T.createWithContext(t,0,s);if(!o.get(h)){if(o.add(h),t===i){if(!s)return void n.addOne(r.EPSILON);if(s.isEmpty()&&c)return void n.addOne(r.EOF)}if(t.constructor.stateType===x.RULE_STOP){if(!s)return void n.addOne(r.EPSILON);if(s.isEmpty()&&c)return void n.addOne(r.EOF);if(s!==N.instance){const e=a.get(t.ruleIndex);try{a.clear(t.ruleIndex);for(let e=0;e=this.states.length)throw new Error("Invalid state number.");const i=this.states[e];let s=this.nextTokens(i);if(!s.contains(r.EPSILON))return s;let n=t;const o=new _;for(o.addSet(s),o.removeOne(r.EPSILON);null!==n&&n.invokingState>=0&&s.contains(r.EPSILON);){const e=this.states[n.invokingState].transitions[0];s=this.nextTokens(e.followState),o.addSet(s),o.removeOne(r.EPSILON),n=n.parent}return s.contains(r.EPSILON)&&o.addOne(r.EOF),o}},J=class e{static{l(this,"KeyTypeEqualityComparer")}static instance=new e;hashCode(e){let t=7;return t=31*t+e.state.stateNumber,t=31*t+e.alt,t=31*t+e.semanticContext.hashCode(),t}equals(e,t){return e===t||e.state.stateNumber===t.state.stateNumber&&e.alt===t.alt&&e.semanticContext.equals(t.semanticContext)}},ee=class{static{l(this,"ATNConfigSet")}configLookup=new p(J.instance);configs=[];uniqueAlt=0;hasSemanticContext=!1;dipsIntoOuterContext=!1;fullCtx=!1;readOnly=!1;conflictingAlts=null;firstStopState;#s=-1;constructor(e){if(void 0!==e)if("boolean"===typeof e)this.fullCtx=e??!0;else{const t=e;this.addAll(t.configs),this.uniqueAlt=t.uniqueAlt,this.conflictingAlts=t.conflictingAlts,this.hasSemanticContext=t.hasSemanticContext,this.dipsIntoOuterContext=t.dipsIntoOuterContext}}[Symbol.iterator](){return this.configs[Symbol.iterator]()}add(e,t=null){if(this.readOnly)throw new Error("This set is readonly");this.firstStopState||e.state.constructor.stateType!==x.RULE_STOP||(this.firstStopState=e),this.hasSemanticContext||=e.semanticContext!==y.NONE,this.dipsIntoOuterContext||=e.reachesIntoOuterContext;const i=this.configLookup.getOrAdd(e);if(i===e)return this.#s=-1,void this.configs.push(e);const s=!this.fullCtx,n=K(i.context,e.context,s,t);i.reachesIntoOuterContext||=e.reachesIntoOuterContext,i.precedenceFilterSuppressed||=e.precedenceFilterSuppressed,i.context=n}get elements(){return this.configs}getAlts(){const e=new h;for(const t of this.configs)e.set(t.alt);return e}getPredicates(){const e=[];for(const t of this.configs)t.semanticContext!==y.NONE&&e.push(t.semanticContext);return e}getStates(){const e=new p;for(const t of this.configs)e.add(t.state);return e}optimizeConfigs(e){if(this.readOnly)throw new Error("This set is readonly");if(0!==this.configLookup.size)for(const t of this.configs)t.context=e.getCachedContext(t.context)}addAll(e){for(const t of e)this.add(t);return!1}equals(e){return this===e||!(this.fullCtx!==e.fullCtx||this.uniqueAlt!==e.uniqueAlt||this.conflictingAlts!==e.conflictingAlts||this.hasSemanticContext!==e.hasSemanticContext||this.dipsIntoOuterContext!==e.dipsIntoOuterContext||!b(this.configs,e.configs))}hashCode(){return-1===this.#s&&(this.#s=this.computeHashCode()),this.#s}get length(){return this.configs.length}isEmpty(){return 0===this.configs.length}contains(e){if(null===this.configLookup)throw new Error("This method is not implemented for readonly sets.");return this.configLookup.contains(e)}containsFast(e){if(null===this.configLookup)throw new Error("This method is not implemented for readonly sets.");return this.configLookup.contains(e)}clear(){if(this.readOnly)throw new Error("This set is readonly");this.configs=[],this.#s=-1,this.configLookup=new p(J.instance)}setReadonly(e){this.readOnly=e,e&&(this.configLookup=null)}toString(){return C(this.configs)+(this.hasSemanticContext?",hasSemanticContext="+this.hasSemanticContext:"")+(this.uniqueAlt!==Z.INVALID_ALT_NUMBER?",uniqueAlt="+this.uniqueAlt:"")+(null!==this.conflictingAlts?",conflictingAlts="+this.conflictingAlts:"")+(this.dipsIntoOuterContext?",dipsIntoOuterContext":"")}computeHashCode(){let e=d.initialize();return this.configs.forEach((t=>{e=d.update(e,t.hashCode())})),e=d.finish(e,this.configs.length),e}},te=class extends x{static{l(this,"BasicState")}static stateType=x.BASIC},ie=class extends x{static{l(this,"DecisionState")}decision=-1;nonGreedy=!1},se=class extends ie{static{l(this,"BlockStartState")}endState},ne=class extends x{static{l(this,"BlockEndState")}static stateType=x.BLOCK_END;startState},re=class extends x{static{l(this,"LoopEndState")}static stateType=x.LOOP_END;loopBackState},oe=class extends x{static{l(this,"RuleStartState")}static stateType=x.RULE_START;stopState;isLeftRecursiveRule=!1},ae=class extends x{static{l(this,"RuleStopState")}static stateType=x.RULE_STOP},le=class extends ie{static{l(this,"TokensStartState")}static stateType=x.TOKEN_START},ce=class extends ie{static{l(this,"PlusLoopbackState")}static stateType=x.PLUS_LOOP_BACK},he=class extends x{static{l(this,"StarLoopbackState")}static stateType=x.STAR_LOOP_BACK},de=class extends ie{static{l(this,"StarLoopEntryState")}static stateType=x.STAR_LOOP_ENTRY;loopBackState;precedenceRuleDecision=!1},ue=class extends se{static{l(this,"PlusBlockStartState")}static stateType=x.PLUS_BLOCK_START;loopBackState},ge=class extends se{static{l(this,"StarBlockStartState")}static stateType=x.STAR_BLOCK_START},pe=class extends se{static{l(this,"BasicBlockStartState")}static stateType=x.BLOCK_START},me=class extends I{static{l(this,"AtomTransition")}labelValue;#n;constructor(e,t){super(e),this.labelValue=t,this.#n=_.of(t,t)}get label(){return this.#n}get transitionType(){return I.ATOM}matches(e){return this.labelValue===e}toString(){return this.labelValue.toString()}},fe=class extends I{static{l(this,"RuleTransition")}ruleIndex;precedence;followState;constructor(e,t,i,s){super(e),this.ruleIndex=t,this.precedence=i,this.followState=s}get isEpsilon(){return!0}get transitionType(){return I.RULE}matches(e,t,i){return!1}},_e=class extends I{static{l(this,"RangeTransition")}start;stop;#n=new _;constructor(e,t,i){super(e),this.start=t,this.stop=i,this.#n.addRange(t,i)}get label(){return this.#n}get transitionType(){return I.RANGE}matches(e,t,i){return e>=this.start&&e<=this.stop}toString(){return"'"+String.fromCharCode(this.start)+"'..'"+String.fromCharCode(this.stop)+"'"}},ve=class extends I{static{l(this,"ActionTransition")}ruleIndex;actionIndex;isCtxDependent;constructor(e,t,i,s){super(e),this.ruleIndex=t,this.actionIndex=i??-1,this.isCtxDependent=s??!1}get isEpsilon(){return!0}get transitionType(){return I.ACTION}matches(e,t,i){return!1}toString(){return"action_"+this.ruleIndex+":"+this.actionIndex}},Ce=class extends I{static{l(this,"EpsilonTransition")}#r;constructor(e,t=-1){super(e),this.#r=t}get outermostPrecedenceReturn(){return this.#r}get isEpsilon(){return!0}get transitionType(){return I.EPSILON}matches(){return!1}toString(){return"epsilon"}},be=class extends I{static{l(this,"WildcardTransition")}get transitionType(){return I.WILDCARD}matches(e,t,i){return e>=t&&e<=i}toString(){return"."}},Ee=class extends I{static{l(this,"AbstractPredicateTransition")}constructor(e){super(e)}},Se=class extends Ee{static{l(this,"PredicateTransition")}ruleIndex;predIndex;isCtxDependent;constructor(e,t,i,s){super(e),this.ruleIndex=t,this.predIndex=i,this.isCtxDependent=s}get isEpsilon(){return!0}matches(e,t,i){return!1}get transitionType(){return I.PREDICATE}getPredicate(){return new y.Predicate(this.ruleIndex,this.predIndex,this.isCtxDependent)}toString(){return"pred_"+this.ruleIndex+":"+this.predIndex}},ye=class extends Ee{static{l(this,"PrecedencePredicateTransition")}precedence;constructor(e,t){super(e),this.precedence=t}get isEpsilon(){return!0}matches(e,t,i){return!1}getPredicate(){return new y.PrecedencePredicate(this.precedence)}get transitionType(){return I.PRECEDENCE}toString(){return this.precedence+" >= _p"}},we=0,Le=1,Re=2,Te=3,xe=4,ke=5,Ae=6,Ne=7,Ie=class e{static{l(this,"LexerSkipAction")}static instance=new e;actionType;isPositionDependent=!1;constructor(){this.actionType=Ae}equals(e){return e===this}hashCode(){return Ae}execute(e){e.skip()}toString(){return"skip"}},Oe=class e{static{l(this,"LexerChannelAction")}channel;actionType;isPositionDependent=!1;cachedHashCode;constructor(e){this.actionType=we,this.channel=e}execute(e){e.channel=this.channel}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();e=d.update(e,this.actionType),e=d.update(e,this.channel),this.cachedHashCode=d.finish(e,2)}return this.cachedHashCode}equals(t){return this===t||t instanceof e&&this.channel===t.channel}toString(){return"channel("+this.channel+")"}},De=class e{static{l(this,"LexerCustomAction")}ruleIndex;actionIndex;actionType;isPositionDependent=!0;cachedHashCode;constructor(e,t){this.actionType=Le,this.ruleIndex=e,this.actionIndex=t}execute(e){e.action(null,this.ruleIndex,this.actionIndex)}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();e=d.update(e,this.actionType),e=d.update(e,this.ruleIndex),e=d.update(e,this.actionIndex),this.cachedHashCode=d.finish(e,3)}return this.cachedHashCode}equals(t){return this===t||t instanceof e&&(this.ruleIndex===t.ruleIndex&&this.actionIndex===t.actionIndex)}},Me=class e{static{l(this,"LexerMoreAction")}static instance=new e;actionType;isPositionDependent=!1;constructor(){this.actionType=Te}equals(e){return e===this}hashCode(){return Te}execute(e){e.more()}toString(){return"more"}},Pe=class e{static{l(this,"LexerTypeAction")}type;actionType;isPositionDependent=!1;cachedHashCode;constructor(e){this.actionType=Ne,this.type=e}execute(e){e.type=this.type}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();e=d.update(e,this.actionType),e=d.update(e,this.type),this.cachedHashCode=d.finish(e,2)}return this.cachedHashCode}equals(t){return this===t||t instanceof e&&this.type===t.type}toString(){return"type("+this.type+")"}},Fe=class e{static{l(this,"LexerPushModeAction")}mode;actionType;isPositionDependent=!1;cachedHashCode;constructor(e){this.actionType=ke,this.mode=e}execute(e){e.pushMode(this.mode)}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();e=d.update(e,this.actionType),e=d.update(e,this.mode),this.cachedHashCode=d.finish(e,2)}return this.cachedHashCode}equals(t){return this===t||t instanceof e&&this.mode===t.mode}toString(){return"pushMode("+this.mode+")"}},Ue=class e{static{l(this,"LexerPopModeAction")}static instance=new e;actionType;isPositionDependent=!1;constructor(){this.actionType=xe}equals(e){return e===this}hashCode(){return xe}execute(e){e.popMode()}toString(){return"popMode"}},He=class e{static{l(this,"LexerModeAction")}mode;actionType;isPositionDependent=!1;cachedHashCode;constructor(e){this.actionType=Re,this.mode=e}execute(e){e.mode=this.mode}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize();e=d.update(e,this.actionType),e=d.update(e,this.mode),this.cachedHashCode=d.finish(e,2)}return this.cachedHashCode}equals(t){return this===t||t instanceof e&&this.mode===t.mode}toString(){return"mode("+this.mode+")"}},Be=class e{static{l(this,"ATNDeserializer")}static SERIALIZED_VERSION=4;static stateTypeMapper=new Map([[x.INVALID_TYPE,void 0],[x.BASIC,te],[x.RULE_START,oe],[x.BLOCK_START,pe],[x.PLUS_BLOCK_START,ue],[x.STAR_BLOCK_START,ge],[x.TOKEN_START,le],[x.RULE_STOP,ae],[x.BLOCK_END,ne],[x.STAR_LOOP_BACK,he],[x.STAR_LOOP_ENTRY,de],[x.PLUS_LOOP_BACK,ce],[x.LOOP_END,re]]);static lexerActionFactoryMapper=new Map([[we,e=>new Oe(e)],[Le,(e,t)=>new De(e,t)],[Re,e=>new He(e)],[Te,()=>Me.instance],[xe,()=>Ue.instance],[ke,e=>new Fe(e)],[Ae,()=>Ie.instance],[Ne,e=>new Pe(e)]]);data=[];pos=0;deserializationOptions;actionFactories;constructor(e){e||(e={readOnly:!1,verifyATN:!0,generateRuleBypassTransitions:!1}),this.deserializationOptions=e}deserialize(e){this.data=e,this.checkVersion();const t=this.readATN();this.readStates(t),this.readRules(t),this.readModes(t);const i=[];return this.readSets(t,i),this.readEdges(t,i),this.readDecisions(t),this.readLexerActions(t),this.markPrecedenceDecisions(t),this.verifyATN(t),this.deserializationOptions.generateRuleBypassTransitions&&t.grammarType===Z.PARSER&&(this.generateRuleBypassTransitions(t),this.verifyATN(t)),t}checkVersion(){const t=this.data[this.pos++];if(t!==e.SERIALIZED_VERSION)throw new Error("Could not deserialize ATN with version "+t+" (expected "+e.SERIALIZED_VERSION+").")}readATN(){const e=this.data[this.pos++],t=this.data[this.pos++];return new Z(e,t)}readStates(e){let t,i;const s=[],n=[],r=this.data[this.pos++];for(let l=0;l0;){const e=l.removeTransition(l.transitions.length-1);n.addTransition(e)}e.ruleToStartState[t].addTransition(new Ce(n)),a&&r.addTransition(new Ce(a));const c=new te;e.addState(c),c.addTransition(new me(r,e.ruleToTokenType[t])),n.addTransition(new Ce(c))}stateIsEndStateFor(e,t){if(e.ruleIndex!==t)return null;if(!(e instanceof de))return null;const i=e.transitions[e.transitions.length-1].target;return i instanceof re&&i.epsilonOnlyTransitions&&i.transitions[0].target instanceof ae?e:null}markPrecedenceDecisions(e){for(const t of e.states)if(t instanceof de&&e.ruleToStartState[t.ruleIndex].isLeftRecursiveRule){const e=t.transitions[t.transitions.length-1].target;e instanceof re&&e.epsilonOnlyTransitions&&e.transitions[0].target instanceof ae&&(t.precedenceRuleDecision=!0)}}verifyATN(e){if(this.deserializationOptions.verifyATN)for(const t of e.states)if(null!==t)if(this.checkCondition(t.epsilonOnlyTransitions||t.transitions.length<=1),t instanceof ue)this.checkCondition(null!==t.loopBackState);else if(t instanceof de)if(this.checkCondition(null!==t.loopBackState),this.checkCondition(2===t.transitions.length),t.transitions[0].target instanceof ge)this.checkCondition(t.transitions[1].target instanceof re),this.checkCondition(!t.nonGreedy);else{if(!(t.transitions[0].target instanceof re))throw new Error("IllegalState");this.checkCondition(t.transitions[1].target instanceof ge),this.checkCondition(t.nonGreedy)}else t instanceof he?(this.checkCondition(1===t.transitions.length),this.checkCondition(t.transitions[0].target instanceof de)):t instanceof re?this.checkCondition(null!==t.loopBackState):t instanceof oe?this.checkCondition(null!==t.stopState):t instanceof se?this.checkCondition(null!==t.endState):t instanceof ne?this.checkCondition(null!==t.startState):t instanceof ie?this.checkCondition(t.transitions.length<=1||t.decision>=0):this.checkCondition(t.transitions.length<=1||t instanceof ae)}checkCondition(e,t){if(!e)throw void 0!==t&&null!==t||(t="IllegalState"),t}edgeFactory(e,t,i,s,n,o,a){const l=e.states[i];switch(t){case I.EPSILON:return new Ce(l);case I.RANGE:return new _e(l,0!==o?r.EOF:s,n);case I.RULE:return new fe(e.states[s],n,o,l);case I.PREDICATE:return new Se(l,s,n,0!==o);case I.PRECEDENCE:return new ye(l,s);case I.ATOM:return new me(l,0!==o?r.EOF:s);case I.ACTION:return new ve(l,s,n,0!==o);case I.SET:return new O(l,a[s]);case I.NOT_SET:return new D(l,a[s]);case I.WILDCARD:return new be(l);default:throw new Error("The specified transition type: "+t+" is not valid.")}}stateFactory(t,i){const s=e.stateTypeMapper.get(t);if(!s)throw new Error("The specified state type "+t+" is not valid.");const n=new s;return n.ruleIndex=i,n}lexerActionFactory(t,i,s){const n=e.lexerActionFactoryMapper.get(t);if(!n)throw new Error("The specified lexer action type "+t+" is not valid.");return n(i,s)}},We=class e extends P{static{l(this,"OrderedHashMap")}#o=[];clear(){super.clear(),this.#o=[]}get(e){return super.get(e)}set(e,t){const i=super.set(e,t);return void 0===i&&this.#o.push(e),i}setIfAbsent(e,t){const i=super.setIfAbsent(e,t);return void 0===i&&this.#o.push(e),i}values(){return{[Symbol.iterator]:()=>{let e=0;return{next:l((()=>e0)for(const t of this.atn.modeToStartState)this.data.push(t.stateNumber)}addRuleStatesAndLexerTokenTypes(){const e=this.atn.ruleToStartState.length;this.data.push(e);for(let t=0;t",this.predicates?e+=C(this.predicates):e+=this.prediction),e.toString()}}),ze=class{static{l(this,"ATNSimulator")}static ERROR=Ve.fromState(2147483647);atn;sharedContextCache;constructor(e,t){return this.atn=e,this.sharedContextCache=t,this}getCachedContext(e){if(!this.sharedContextCache)return e;const t=new P(u.instance);return j(e,this.sharedContextCache,t)}},Ge=(class e{static{l(this,"CodePointTransitions")}static createWithCodePoint(t,i){return e.createWithCodePointRange(t,i,i)}static createWithCodePointRange(e,t,i){return t===i?new me(e,t):new _e(e,t,i)}},class{static{l(this,"DecisionInfo")}decision=0;invocations=0;timeInPrediction=0;sllTotalLook=0;sllMinLook=0;sllMaxLook=0;sllMaxLookEvent;llTotalLook=0;llMinLook=0;llMaxLook=0;llMaxLookEvent;contextSensitivities;errors;ambiguities;predicateEvals;sllATNTransitions=0;sllDFATransitions=0;llFallback=0;llATNTransitions=0;llDFATransitions=0;constructor(e){this.decision=e,this.contextSensitivities=[],this.errors=[],this.ambiguities=[],this.predicateEvals=[]}toString(){return"{decision="+this.decision+", contextSensitivities="+this.contextSensitivities.length+", errors="+this.errors.length+", ambiguities="+this.ambiguities.length+", sllLookahead="+this.sllTotalLook+", sllATNTransitions="+this.sllATNTransitions+", sllDFATransitions="+this.sllDFATransitions+", llFallback="+this.llFallback+", llLookahead="+this.llTotalLook+", llATNTransitions="+this.llATNTransitions+"}"}}),je=class e extends T{static{l(this,"LexerATNConfig")}lexerActionExecutor;passedThroughNonGreedyDecision;constructor(t,i,s,n){return super(t,i,s??t.context,s?y.NONE:t.semanticContext),this.lexerActionExecutor=s?n:t.lexerActionExecutor??null,this.passedThroughNonGreedyDecision=e.checkNonGreedyDecision(t,this.state),this}static createWithExecutor(t,i,s){return new e(t,i,t.context,s)}static createWithConfig(t,i,s){return new e(i,t,s??null,i.lexerActionExecutor)}static createWithContext(t,i,s){return new e({alt:i},t,s,null)}static checkNonGreedyDecision(e,t){return e.passedThroughNonGreedyDecision||"nonGreedy"in t&&t.nonGreedy}hashCode(){if(void 0===this.cachedHashCode){let e=d.initialize(7);e=d.update(e,this.state.stateNumber),e=d.update(e,this.alt),e=d.updateFromComparable(e,this.context),e=d.updateFromComparable(e,this.semanticContext),e=d.update(e,this.passedThroughNonGreedyDecision?1:0),e=d.updateFromComparable(e,this.lexerActionExecutor),e=d.finish(e,6),this.cachedHashCode=e}return this.cachedHashCode}equals(e){return this===e||this.passedThroughNonGreedyDecision===e.passedThroughNonGreedyDecision&&(this.lexerActionExecutor&&e.lexerActionExecutor?this.lexerActionExecutor.equals(e.lexerActionExecutor):!e.lexerActionExecutor)&&super.equals(e)}},Ke=class{static{l(this,"BaseErrorListener")}syntaxError(e,t,i,s,n,r){}reportAmbiguity(e,t,i,s,n,r,o){}reportAttemptingFullContext(e,t,i,s,n,r){}reportContextSensitivity(e,t,i,s,n,r){}},Ye=class e extends Ke{static{l(this,"ConsoleErrorListener")}static instance=new e;syntaxError(e,t,i,s,n,r){console.error("line "+i+":"+s+" "+n)}},qe=class extends Ke{constructor(e){return super(),this.delegates=e,this}static{l(this,"ProxyErrorListener")}syntaxError(e,t,i,s,n,r){this.delegates.forEach((o=>{o.syntaxError(e,t,i,s,n,r)}))}reportAmbiguity(e,t,i,s,n,r,o){this.delegates.forEach((a=>{a.reportAmbiguity(e,t,i,s,n,r,o)}))}reportAttemptingFullContext(e,t,i,s,n,r){this.delegates.forEach((o=>{o.reportAttemptingFullContext(e,t,i,s,n,r)}))}reportContextSensitivity(e,t,i,s,n,r){this.delegates.forEach((o=>{o.reportContextSensitivity(e,t,i,s,n,r)}))}},$e=class e{static{l(this,"Recognizer")}static EOF=-1;static tokenTypeMapCache=new Map;static ruleIndexMapCache=new Map;interpreter;listeners=[Ye.instance];stateNumber=-1;checkVersion(e){const t="4.13.1";t!==e&&console.error("ANTLR runtime and generated code versions disagree: "+t+"!="+e)}addErrorListener(e){this.listeners.push(e)}removeErrorListeners(){this.listeners=[]}removeErrorListener(e){for(let t=0;ti.set(e,t))),e.ruleIndexMapCache.set(t,i)),i}getTokenType(e){const t=this.getTokenTypeMap().get(e);return t||r.INVALID_TYPE}getErrorHeader(e){const t=e.offendingToken?.line,i=e.offendingToken?.column;return"line "+t+":"+i}get errorListenerDispatch(){return new qe(this.listeners)}sempred(e,t,i){return!0}precpred(e,t){return!0}action(e,t,i){}get atn(){return this.interpreter.atn}get state(){return this.stateNumber}set state(e){this.stateNumber=e}getParseInfo(){}},Qe=class e{static{l(this,"CommonTokenFactory")}static DEFAULT=new e;copyText=!1;constructor(e){this.copyText=e??!1}create(e,t,i,s,n,r,o,a){const l=H.fromSource(e,t,s,n,r);return l.line=o,l.column=a,i?l.text=i:this.copyText&&null!==e[1]&&(l.text=e[1].getTextFromRange(n,r)),l}},Xe=class e extends Error{static{l(this,"RecognitionException")}ctx;offendingToken=null;offendingState=-1;recognizer;input;constructor(t){super(t.message),Error.captureStackTrace&&Error.captureStackTrace(this,e),this.message=t.message,this.recognizer=t.recognizer,this.input=t.input,this.ctx=t.ctx,null!==this.recognizer&&(this.offendingState=this.recognizer.state)}getExpectedTokens(){return null!==this.recognizer&&null!==this.ctx?this.recognizer.atn.getExpectedTokens(this.offendingState,this.ctx):null}toString(){return this.message}},Ze=class extends Xe{static{l(this,"LexerNoViableAltException")}startIndex;deadEndConfigs;constructor(e,t,i,s){super({message:"",recognizer:e,input:t,ctx:null}),this.startIndex=i,this.deadEndConfigs=s}toString(){let e="";return this.input&&this.startIndex>=0&&this.startIndex